2025.07.28 11:45:30.604419 [ 423 ] {} Context: Server was built in debug mode. It will work slowly. 2025.07.28 11:45:30.605082 [ 423 ] {} Context: ThreadFuzzer is enabled. Application will run slowly and unstable. 2025.07.28 11:45:34.195907 [ 423 ] {} KeeperLogStore: No logs exists in /var/lib/clickhouse/coordination/logs. It's Ok if it's the first run of clickhouse-keeper. 2025.07.28 11:45:34.198989 [ 423 ] {} KeeperLogStore: Removing all changelogs 2025.07.28 11:45:34.205068 [ 423 ] {} KeeperServer: Got 1000000000000000 value for setting 'reserved_log_items' which is bigger than int32_t max value, lowering value to 2147483647. 2025.07.28 11:45:34.217822 [ 423 ] {} RaftInstance: invalid election timeout lower bound detected, adjusted to 0 2025.07.28 11:45:34.218261 [ 423 ] {} RaftInstance: invalid election timeout upper bound detected, adjusted to 0 2025.07.28 11:45:34.288200 [ 1037 ] {} RaftInstance: Election timeout, initiate leader election 2025.07.28 11:45:34.805764 [ 423 ] {} Access(local_directory): File /var/lib/clickhouse/access/users.list doesn't exist 2025.07.28 11:45:34.806312 [ 423 ] {} Access(local_directory): Recovering lists in directory /var/lib/clickhouse/access/ 2025.07.28 11:45:35.033578 [ 423 ] {} 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.07.28 11:45:35.038735 [ 423 ] {} 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.07.28 11:45:53.819033 [ 430 ] {f8713c7c-2b9f-4cd4-9bc7-a216196d1a0a} 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.07.28 11:46:04.590090 [ 430 ] {5b3c9cf8-8cd6-44f3-afb4-4528f88a203c} 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.07.28 11:46:22.385837 [ 1059 ] {} RaftInstance: failed to accept a rpc connection due to error 125, Operation canceled 2025.07.28 11:46:27.696105 [ 1556 ] {} Context: Server was built in debug mode. It will work slowly. 2025.07.28 11:46:27.696937 [ 1556 ] {} Context: ThreadFuzzer is enabled. Application will run slowly and unstable. 2025.07.28 11:46:30.968128 [ 1556 ] {} KeeperServer: Got 1000000000000000 value for setting 'reserved_log_items' which is bigger than int32_t max value, lowering value to 2147483647. 2025.07.28 11:46:30.985156 [ 1556 ] {} RaftInstance: invalid election timeout lower bound detected, adjusted to 0 2025.07.28 11:46:30.985565 [ 1556 ] {} RaftInstance: invalid election timeout upper bound detected, adjusted to 0 2025.07.28 11:46:31.044345 [ 2178 ] {} RaftInstance: Election timeout, initiate leader election 2025.07.28 11:46:31.724352 [ 1556 ] {} 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.07.28 11:46:31.731477 [ 1556 ] {} 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.07.28 11:47:31.472239 [ 1563 ] {ad26efd3-5749-48b2-8abe-013fc06b3f21} executeQuery: Code: 241. DB::Exception: User memory limit exceeded: would use 9.18 GiB (attempt to allocate chunk of 1.01 MiB bytes), maximum: 9.18 GiB. OvercommitTracker decision: Query was selected to stop by OvercommitTracker: While reading or decompressing store/78e/78ebf6a1-d987-4579-b3ec-00c1a087b1f3/201403_1_1_2/RefererDomain.bin (position: 349347, typename: DB::AsynchronousBoundedReadBuffer, compressed data header: 6e48797703fcb1f2cc90157a2de4dae482ca68000065180200): (while reading column RefererDomain): (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 32 with max_rows_to_read = 8192): While executing MergeTreeSelect(pool: ReadPool, algorithm: Thread). (MEMORY_LIMIT_EXCEEDED) (version 25.3.6.10636.altinitytest (altinity build)) (from [::1]:57642) (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. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000000fc1ab36 4. /build/src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000000fc196ef 5. /build/src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000000fc19293 6. /build/src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000000fc19293 7. /build/src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000000fb80c54 8. /build/src/Common/Allocator.cpp:233: Allocator::realloc(void*, unsigned long, unsigned long, unsigned long) @ 0x000000000fb7f7df 9. /build/src/IO/BufferWithOwnMemory.h:98: DB::Memory>::resize(unsigned long) @ 0x000000000fc803d7 10. /build/src/Compression/CompressedReadBufferFromFile.cpp:36: DB::CompressedReadBufferFromFile::nextImpl() @ 0x0000000017937d73 11. /build/src/IO/ReadBuffer.h:60: DB::ReadBuffer::next() @ 0x000000000a148c7b 12. /build/src/IO/ReadBuffer.h:96: void DB::deserializeBinarySSE2<1>(DB::PODArray, 63ul, 64ul>&, DB::PODArray, 63ul, 64ul>&, DB::ReadBuffer&, unsigned long) @ 0x0000000013d15af2 13. /build/src/DataTypes/Serializations/ISerialization.cpp:147: DB::ISerialization::deserializeBinaryBulkWithMultipleStreams(COW::immutable_ptr&, unsigned long, DB::ISerialization::DeserializeBinaryBulkSettings&, std::shared_ptr&, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>*) const @ 0x0000000013c7b663 14. /build/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>>>&) @ 0x00000000164a9d8e 15. /build/src/Storages/MergeTree/MergeTreeReaderWide.cpp:172: DB::MergeTreeReaderWide::readRows(unsigned long, unsigned long, bool, unsigned long, std::vector::immutable_ptr, std::allocator::immutable_ptr>>&) @ 0x00000000164a94d2 16. /build/src/Storages/MergeTree/MergeTreeRangeReader.cpp:116: DB::MergeTreeRangeReader::DelayedStream::finalize(std::vector::immutable_ptr, std::allocator::immutable_ptr>>&) @ 0x0000000016497db1 17. /build/src/Storages/MergeTree/MergeTreeRangeReader.cpp:298: DB::MergeTreeRangeReader::startReadingChain(unsigned long, DB::MarkRanges&) @ 0x000000001649f129 18. /build/src/Storages/MergeTree/MergeTreeReadersChain.cpp:67: DB::MergeTreeReadersChain::read(unsigned long, DB::MarkRanges&) @ 0x00000000164b9dda 19. /build/src/Storages/MergeTree/MergeTreeReadTask.cpp:172: DB::MergeTreeReadTask::read() @ 0x00000000164b6300 20. /build/src/Storages/MergeTree/MergeTreeSelectAlgorithms.h:38: DB::MergeTreeThreadSelectAlgorithm::readFromTask(DB::MergeTreeReadTask&) @ 0x0000000016e3caac 21. /build/src/Storages/MergeTree/MergeTreeSelectProcessor.cpp:207: DB::MergeTreeSelectProcessor::read() @ 0x00000000164c0ba4 22. /build/src/Storages/MergeTree/MergeTreeSource.cpp:229: DB::MergeTreeSource::tryGenerate() @ 0x0000000016e43d69 23. /build/src/Processors/ISource.cpp:108: DB::ISource::work() @ 0x00000000169a21e7 24. /build/src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x00000000169bd00f 25. /build/src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x00000000169b2105 26. /build/src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeSingleThread(unsigned long) @ 0x00000000169b23be 27. /build/src/Processors/Executors/PipelineExecutor.cpp:416: void std::__function::__policy_invoker::__call_impl[abi:se190107]>(std::__function::__policy_storage const*) @ 0x00000000169b2e3f 28. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc6653 29. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000000fccc4c3 30. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc3d92 31. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fcca080 2025.07.28 11:47:44.823131 [ 1563 ] {} TCPHandler: Code: 241. DB::Exception: User memory limit exceeded: would use 9.18 GiB (attempt to allocate chunk of 1.01 MiB bytes), maximum: 9.18 GiB. OvercommitTracker decision: Query was selected to stop by OvercommitTracker: While reading or decompressing store/78e/78ebf6a1-d987-4579-b3ec-00c1a087b1f3/201403_1_1_2/RefererDomain.bin (position: 349347, typename: DB::AsynchronousBoundedReadBuffer, compressed data header: 6e48797703fcb1f2cc90157a2de4dae482ca68000065180200): (while reading column RefererDomain): (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 32 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. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000000fc1ab36 4. /build/src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000000fc196ef 5. /build/src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000000fc19293 6. /build/src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000000fc19293 7. /build/src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000000fb80c54 8. /build/src/Common/Allocator.cpp:233: Allocator::realloc(void*, unsigned long, unsigned long, unsigned long) @ 0x000000000fb7f7df 9. /build/src/IO/BufferWithOwnMemory.h:98: DB::Memory>::resize(unsigned long) @ 0x000000000fc803d7 10. /build/src/Compression/CompressedReadBufferFromFile.cpp:36: DB::CompressedReadBufferFromFile::nextImpl() @ 0x0000000017937d73 11. /build/src/IO/ReadBuffer.h:60: DB::ReadBuffer::next() @ 0x000000000a148c7b 12. /build/src/IO/ReadBuffer.h:96: void DB::deserializeBinarySSE2<1>(DB::PODArray, 63ul, 64ul>&, DB::PODArray, 63ul, 64ul>&, DB::ReadBuffer&, unsigned long) @ 0x0000000013d15af2 13. /build/src/DataTypes/Serializations/ISerialization.cpp:147: DB::ISerialization::deserializeBinaryBulkWithMultipleStreams(COW::immutable_ptr&, unsigned long, DB::ISerialization::DeserializeBinaryBulkSettings&, std::shared_ptr&, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>*) const @ 0x0000000013c7b663 14. /build/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>>>&) @ 0x00000000164a9d8e 15. /build/src/Storages/MergeTree/MergeTreeReaderWide.cpp:172: DB::MergeTreeReaderWide::readRows(unsigned long, unsigned long, bool, unsigned long, std::vector::immutable_ptr, std::allocator::immutable_ptr>>&) @ 0x00000000164a94d2 16. /build/src/Storages/MergeTree/MergeTreeRangeReader.cpp:116: DB::MergeTreeRangeReader::DelayedStream::finalize(std::vector::immutable_ptr, std::allocator::immutable_ptr>>&) @ 0x0000000016497db1 17. /build/src/Storages/MergeTree/MergeTreeRangeReader.cpp:298: DB::MergeTreeRangeReader::startReadingChain(unsigned long, DB::MarkRanges&) @ 0x000000001649f129 18. /build/src/Storages/MergeTree/MergeTreeReadersChain.cpp:67: DB::MergeTreeReadersChain::read(unsigned long, DB::MarkRanges&) @ 0x00000000164b9dda 19. /build/src/Storages/MergeTree/MergeTreeReadTask.cpp:172: DB::MergeTreeReadTask::read() @ 0x00000000164b6300 20. /build/src/Storages/MergeTree/MergeTreeSelectAlgorithms.h:38: DB::MergeTreeThreadSelectAlgorithm::readFromTask(DB::MergeTreeReadTask&) @ 0x0000000016e3caac 21. /build/src/Storages/MergeTree/MergeTreeSelectProcessor.cpp:207: DB::MergeTreeSelectProcessor::read() @ 0x00000000164c0ba4 22. /build/src/Storages/MergeTree/MergeTreeSource.cpp:229: DB::MergeTreeSource::tryGenerate() @ 0x0000000016e43d69 23. /build/src/Processors/ISource.cpp:108: DB::ISource::work() @ 0x00000000169a21e7 24. /build/src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x00000000169bd00f 25. /build/src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x00000000169b2105 26. /build/src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeSingleThread(unsigned long) @ 0x00000000169b23be 27. /build/src/Processors/Executors/PipelineExecutor.cpp:416: void std::__function::__policy_invoker::__call_impl[abi:se190107]>(std::__function::__policy_storage const*) @ 0x00000000169b2e3f 28. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc6653 29. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000000fccc4c3 30. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc3d92 31. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fcca080 Job's origin stack trace: 0. /build/src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000000fc33b84 1. /build/src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000000fcc2ea7 2. /build/src/Common/ThreadPool.cpp:401: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fcc7f1c 3. /build/src/Common/ThreadPool.cpp:494: ThreadPoolImpl>::scheduleOrThrowOnError(std::function, Priority) @ 0x000000000fcc7a0e 4. /build/src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::spawnThreadsImpl() @ 0x00000000169b2c0c 5. /build/src/Processors/Executors/PipelineExecutor.cpp:394: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x00000000169b0ba7 6. /build/src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x00000000169b03f4 7. /build/src/Processors/Executors/CompletedPipelineExecutor.cpp:42: void std::__function::__policy_invoker::__call_impl[abi:se190107]::ThreadFromGlobalPoolImpl(DB::CompletedPipelineExecutor::execute()::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169af7e1 8. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc3d92 9. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fcca080 10. ? @ 0x00007f4fd3b5aac3 11. ? @ 0x00007f4fd3bec850 Job's origin stack trace: 0. /build/src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000000fc33b84 1. /build/src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000000fcc2ea7 2. /build/src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fcc535c 3. /build/src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000000fcc584d 4. /build/src/Common/ThreadPool.h:279: DB::CompletedPipelineExecutor::execute() @ 0x00000000169af267 5. /build/src/Server/TCPHandler.cpp:707: DB::TCPHandler::runImpl() @ 0x00000000168e6b2e 6. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 7. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 8. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 9. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 10. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 11. ? @ 0x00007f4fd3b5aac3 12. ? @ 0x00007f4fd3bec850 2025.07.28 11:48:13.130533 [ 1563 ] {489a780f-b36d-4e52-a122-0fb55d444b6a} executeQuery: Code: 241. DB::Exception: User memory limit exceeded: would use 9.20 GiB (attempt to allocate chunk of 1.06 MiB bytes), maximum: 9.18 GiB. OvercommitTracker decision: Query was selected to stop by OvercommitTracker: (while reading column SocialAction): (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 228 with max_rows_to_read = 8192): While executing MergeTreeSelect(pool: ReadPool, algorithm: Thread). (MEMORY_LIMIT_EXCEEDED) (version 25.3.6.10636.altinitytest (altinity build)) (from [::1]:50022) (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. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000000fc1ab36 4. /build/src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000000fc196ef 5. /build/src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000000fc19293 6. /build/src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000000fc19293 7. /build/src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000000fb80c54 8. /build/src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000000fb7f3c4 9. /build/src/Common/PODArray.h:118: DB::SerializationString::deserializeBinaryBulk(DB::IColumn&, DB::ReadBuffer&, unsigned long, double) const @ 0x0000000013d14874 10. /build/src/DataTypes/Serializations/ISerialization.cpp:147: DB::ISerialization::deserializeBinaryBulkWithMultipleStreams(COW::immutable_ptr&, unsigned long, DB::ISerialization::DeserializeBinaryBulkSettings&, std::shared_ptr&, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>*) const @ 0x0000000013c7b663 11. /build/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>>>&) @ 0x00000000164a9d8e 12. /build/src/Storages/MergeTree/MergeTreeReaderWide.cpp:172: DB::MergeTreeReaderWide::readRows(unsigned long, unsigned long, bool, unsigned long, std::vector::immutable_ptr, std::allocator::immutable_ptr>>&) @ 0x00000000164a94d2 13. /build/src/Storages/MergeTree/MergeTreeRangeReader.cpp:116: DB::MergeTreeRangeReader::DelayedStream::finalize(std::vector::immutable_ptr, std::allocator::immutable_ptr>>&) @ 0x0000000016497db1 14. /build/src/Storages/MergeTree/MergeTreeRangeReader.cpp:298: DB::MergeTreeRangeReader::startReadingChain(unsigned long, DB::MarkRanges&) @ 0x000000001649f129 15. /build/src/Storages/MergeTree/MergeTreeReadersChain.cpp:67: DB::MergeTreeReadersChain::read(unsigned long, DB::MarkRanges&) @ 0x00000000164b9dda 16. /build/src/Storages/MergeTree/MergeTreeReadTask.cpp:172: DB::MergeTreeReadTask::read() @ 0x00000000164b6300 17. /build/src/Storages/MergeTree/MergeTreeSelectAlgorithms.h:38: DB::MergeTreeThreadSelectAlgorithm::readFromTask(DB::MergeTreeReadTask&) @ 0x0000000016e3caac 18. /build/src/Storages/MergeTree/MergeTreeSelectProcessor.cpp:207: DB::MergeTreeSelectProcessor::read() @ 0x00000000164c0ba4 19. /build/src/Storages/MergeTree/MergeTreeSource.cpp:229: DB::MergeTreeSource::tryGenerate() @ 0x0000000016e43d69 20. /build/src/Processors/ISource.cpp:108: DB::ISource::work() @ 0x00000000169a21e7 21. /build/src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x00000000169bd00f 22. /build/src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x00000000169b2105 23. /build/src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeSingleThread(unsigned long) @ 0x00000000169b23be 24. /build/src/Processors/Executors/PipelineExecutor.cpp:416: void std::__function::__policy_invoker::__call_impl[abi:se190107]>(std::__function::__policy_storage const*) @ 0x00000000169b2e3f 25. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc6653 26. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000000fccc4c3 27. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc3d92 28. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fcca080 29. ? @ 0x00007f4fd3b5aac3 30. ? @ 0x00007f4fd3bec850 2025.07.28 11:48:25.924393 [ 1563 ] {} TCPHandler: Code: 241. DB::Exception: User memory limit exceeded: would use 9.20 GiB (attempt to allocate chunk of 1.06 MiB bytes), maximum: 9.18 GiB. OvercommitTracker decision: Query was selected to stop by OvercommitTracker: (while reading column SocialAction): (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 228 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. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000000fc1ab36 4. /build/src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000000fc196ef 5. /build/src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000000fc19293 6. /build/src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000000fc19293 7. /build/src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000000fb80c54 8. /build/src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000000fb7f3c4 9. /build/src/Common/PODArray.h:118: DB::SerializationString::deserializeBinaryBulk(DB::IColumn&, DB::ReadBuffer&, unsigned long, double) const @ 0x0000000013d14874 10. /build/src/DataTypes/Serializations/ISerialization.cpp:147: DB::ISerialization::deserializeBinaryBulkWithMultipleStreams(COW::immutable_ptr&, unsigned long, DB::ISerialization::DeserializeBinaryBulkSettings&, std::shared_ptr&, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>*) const @ 0x0000000013c7b663 11. /build/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>>>&) @ 0x00000000164a9d8e 12. /build/src/Storages/MergeTree/MergeTreeReaderWide.cpp:172: DB::MergeTreeReaderWide::readRows(unsigned long, unsigned long, bool, unsigned long, std::vector::immutable_ptr, std::allocator::immutable_ptr>>&) @ 0x00000000164a94d2 13. /build/src/Storages/MergeTree/MergeTreeRangeReader.cpp:116: DB::MergeTreeRangeReader::DelayedStream::finalize(std::vector::immutable_ptr, std::allocator::immutable_ptr>>&) @ 0x0000000016497db1 14. /build/src/Storages/MergeTree/MergeTreeRangeReader.cpp:298: DB::MergeTreeRangeReader::startReadingChain(unsigned long, DB::MarkRanges&) @ 0x000000001649f129 15. /build/src/Storages/MergeTree/MergeTreeReadersChain.cpp:67: DB::MergeTreeReadersChain::read(unsigned long, DB::MarkRanges&) @ 0x00000000164b9dda 16. /build/src/Storages/MergeTree/MergeTreeReadTask.cpp:172: DB::MergeTreeReadTask::read() @ 0x00000000164b6300 17. /build/src/Storages/MergeTree/MergeTreeSelectAlgorithms.h:38: DB::MergeTreeThreadSelectAlgorithm::readFromTask(DB::MergeTreeReadTask&) @ 0x0000000016e3caac 18. /build/src/Storages/MergeTree/MergeTreeSelectProcessor.cpp:207: DB::MergeTreeSelectProcessor::read() @ 0x00000000164c0ba4 19. /build/src/Storages/MergeTree/MergeTreeSource.cpp:229: DB::MergeTreeSource::tryGenerate() @ 0x0000000016e43d69 20. /build/src/Processors/ISource.cpp:108: DB::ISource::work() @ 0x00000000169a21e7 21. /build/src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x00000000169bd00f 22. /build/src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x00000000169b2105 23. /build/src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeSingleThread(unsigned long) @ 0x00000000169b23be 24. /build/src/Processors/Executors/PipelineExecutor.cpp:416: void std::__function::__policy_invoker::__call_impl[abi:se190107]>(std::__function::__policy_storage const*) @ 0x00000000169b2e3f 25. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc6653 26. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000000fccc4c3 27. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc3d92 28. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fcca080 29. ? @ 0x00007f4fd3b5aac3 30. ? @ 0x00007f4fd3bec850 Job's origin stack trace: 0. /build/src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000000fc33b84 1. /build/src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000000fcc2ea7 2. /build/src/Common/ThreadPool.cpp:401: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fcc7f1c 3. /build/src/Common/ThreadPool.cpp:494: ThreadPoolImpl>::scheduleOrThrowOnError(std::function, Priority) @ 0x000000000fcc7a0e 4. /build/src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::spawnThreadsImpl() @ 0x00000000169b2c0c 5. /build/src/Processors/Executors/PipelineExecutor.cpp:394: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x00000000169b20b2 6. /build/src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeSingleThread(unsigned long) @ 0x00000000169b23be 7. /build/src/Processors/Executors/PipelineExecutor.cpp:416: void std::__function::__policy_invoker::__call_impl[abi:se190107]>(std::__function::__policy_storage const*) @ 0x00000000169b2e3f 8. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc6653 9. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000000fccc4c3 10. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc3d92 11. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fcca080 12. ? @ 0x00007f4fd3b5aac3 13. ? @ 0x00007f4fd3bec850 Job's origin stack trace: 0. /build/src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000000fc33b84 1. /build/src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000000fcc2ea7 2. /build/src/Common/ThreadPool.cpp:401: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fcc7f1c 3. /build/src/Common/ThreadPool.cpp:494: ThreadPoolImpl>::scheduleOrThrowOnError(std::function, Priority) @ 0x000000000fcc7a0e 4. /build/src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::spawnThreadsImpl() @ 0x00000000169b2c0c 5. /build/src/Processors/Executors/PipelineExecutor.cpp:394: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x00000000169b0ba7 6. /build/src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x00000000169b03f4 7. /build/src/Processors/Executors/CompletedPipelineExecutor.cpp:42: void std::__function::__policy_invoker::__call_impl[abi:se190107]::ThreadFromGlobalPoolImpl(DB::CompletedPipelineExecutor::execute()::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169af7e1 8. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc3d92 9. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fcca080 10. ? @ 0x00007f4fd3b5aac3 11. ? @ 0x00007f4fd3bec850 Job's origin stack trace: 0. /build/src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000000fc33b84 1. /build/src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000000fcc2ea7 2. /build/src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fcc535c 3. /build/src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000000fcc584d 4. /build/src/Common/ThreadPool.h:279: DB::CompletedPipelineExecutor::execute() @ 0x00000000169af267 5. /build/src/Server/TCPHandler.cpp:707: DB::TCPHandler::runImpl() @ 0x00000000168e6b2e 6. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 7. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 8. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 9. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 10. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 11. ? @ 0x00007f4fd3b5aac3 12. ? @ 0x00007f4fd3bec850 2025.07.28 11:49:08.613693 [ 2220 ] {448ac907-4a90-4f55-a4c3-4fe5d2b48cad::201403_1_7_2} 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. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000000a074fcb 4. /build/src/Storages/MergeTree/MergeTask.cpp:244: DB::MergeTask::GlobalRuntimeContext::checkOperationIsNotCanceled() const @ 0x00000000162cab7a 5. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000162eeb33 6. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000013bb1dc9 7. /build/src/Processors/Executors/ExecutionThreadContext.cpp:68: DB::ExecutionThreadContext::executeTask() @ 0x00000000169bd08f 8. /build/src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x00000000169b2105 9. /build/src/Processors/Executors/PipelineExecutor.cpp:170: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x00000000169b16a7 10. /build/src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x00000000169c081c 11. /build/src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x00000000169c0978 12. /build/src/Storages/MergeTree/MergeTask.cpp:1191: DB::MergeTask::VerticalMergeStage::executeVerticalMergeForOneColumn() const @ 0x00000000162da16b 13. /build/src/Storages/MergeTree/MergeTask.cpp:1463: DB::MergeTask::VerticalMergeStage::executeVerticalMergeForAllColumns() const @ 0x00000000162dc988 14. /build/src/Storages/MergeTree/MergeTask.cpp:1392: DB::MergeTask::VerticalMergeStage::execute() @ 0x00000000162dc4f9 15. /build/src/Storages/MergeTree/MergeTask.cpp:1485: DB::MergeTask::execute() @ 0x00000000162dbf2a 16. /build/src/Storages/MergeTree/MergePlainMergeTreeTask.cpp:57: DB::MergePlainMergeTreeTask::executeStep() @ 0x000000001666e865 17. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000162fc850 18. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x00000000162fd193 19. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc6653 20. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000000fccc4c3 21. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc3d92 22. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fcca080 23. ? @ 0x00007f4fd3b5aac3 24. ? @ 0x00007f4fd3bec850 (version 25.3.6.10636.altinitytest (altinity build)) 2025.07.28 11:49:10.422290 [ 3278 ] {} Context: Server was built in debug mode. It will work slowly. 2025.07.28 11:49:10.423122 [ 3278 ] {} Context: ThreadFuzzer is enabled. Application will run slowly and unstable. 2025.07.28 11:49:13.736058 [ 3278 ] {} KeeperServer: Got 1000000000000000 value for setting 'reserved_log_items' which is bigger than int32_t max value, lowering value to 2147483647. 2025.07.28 11:49:13.750423 [ 3278 ] {} RaftInstance: invalid election timeout lower bound detected, adjusted to 0 2025.07.28 11:49:13.750964 [ 3278 ] {} RaftInstance: invalid election timeout upper bound detected, adjusted to 0 2025.07.28 11:49:13.814360 [ 3898 ] {} RaftInstance: Election timeout, initiate leader election 2025.07.28 11:49:14.858036 [ 3278 ] {} Context: Server logging level is set to 'test' and performance is degraded. This cannot be used in production. 2025.07.28 11:49:14.860674 [ 3278 ] {} 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.07.28 11:49:14.868803 [ 3278 ] {} 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.07.28 11:49:44.222956 [ 3285 ] {0c318337-6ec1-40cf-8d1f-71dc6d279df4} executeQuery: Code: 46. DB::Exception: Function with name `sumIF` does not exist. In scope SELECT sumIF(1, 0). (UNKNOWN_FUNCTION) (version 25.3.6.10636.altinitytest (altinity build)) (from [::1]:33408) (comment: 02177_sum_if_not_found.sql) (query 4, line 4) (in query: SELECT sumIF(1, 0);), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&) @ 0x000000000a10182b 4. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3351: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000140362e2 5. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3838: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000014019a9e 6. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3980: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000014018e31 7. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:4304: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000014042fa7 8. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5605: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000014013749 9. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000140127f9 10. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000014011fce 11. /build/src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000001406ce8a 12. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000014973b42 13. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000001497268d 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000014974d24 15. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001492924b 16. /build/src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88641 17. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 18. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 19. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 20. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 21. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 22. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 23. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 24. ? @ 0x00007fbc6213eac3 25. ? @ 0x00007fbc621d0850 2025.07.28 11:49:44.254546 [ 3285 ] {} TCPHandler: Code: 46. DB::Exception: Function with name `sumIF` does not exist. In scope SELECT sumIF(1, 0). (UNKNOWN_FUNCTION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&) @ 0x000000000a10182b 4. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3351: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000140362e2 5. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3838: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000014019a9e 6. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3980: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000014018e31 7. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:4304: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000014042fa7 8. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5605: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000014013749 9. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000140127f9 10. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000014011fce 11. /build/src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000001406ce8a 12. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000014973b42 13. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000001497268d 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000014974d24 15. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001492924b 16. /build/src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88641 17. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 18. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 19. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 20. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 21. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 22. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 23. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 24. ? @ 0x00007fbc6213eac3 25. ? @ 0x00007fbc621d0850 2025.07.28 11:49:44.856889 [ 3285 ] {ceddea31-4aed-4af6-819c-d5b2918baa13} executeQuery: Code: 46. DB::Exception: Function with name `sumIF` does not exist. In scope SELECT t, sumIF(n, 0) FROM data GROUP BY t. (UNKNOWN_FUNCTION) (version 25.3.6.10636.altinitytest (altinity build)) (from [::1]:33408) (comment: 02177_sum_if_not_found.sql) (query 8, line 16) (in query: CREATE TABLE agg ENGINE = AggregatingMergeTree ORDER BY tuple() SETTINGS index_granularity = 6150, 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 = 505627594, compact_parts_max_bytes_to_buffer = 224761410, compact_parts_max_granules_to_buffer = 256, compact_parts_merge_max_bytes_to_prefetch_part = 21799741, merge_max_block_size = 15477, old_parts_lifetime = 350., 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 = 10737418240, index_granularity_bytes = 4954563, 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 = false, enable_block_offset_column = false, cache_populated_by_fetch = false, marks_compress_block_size = 98095, primary_key_compress_block_size = 58281, use_primary_key_cache = true, prewarm_primary_key_cache = true, prewarm_mark_cache = true AS SELECT t, sumIF(n, 0) FROM data GROUP BY t), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&) @ 0x000000000a10182b 4. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3351: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000140362e2 5. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3838: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000014019a9e 6. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3980: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000014018e31 7. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:4304: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000014042fa7 8. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5605: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000014013749 9. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000140127f9 10. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000014011fce 11. /build/src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000001406ce8a 12. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000014973b42 13. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000001497268d 14. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:205: DB::InterpreterSelectQueryAnalyzer::getSampleBlock(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000014973e7b 15. /build/src/Interpreters/InterpreterCreateQuery.cpp:957: DB::InterpreterCreateQuery::getTablePropertiesAndNormalizeCreateQuery(DB::ASTCreateQuery&, DB::LoadingStrictnessLevel) const @ 0x00000000148f0043 16. /build/src/Interpreters/InterpreterCreateQuery.cpp:1657: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000148f901b 17. /build/src/Interpreters/InterpreterCreateQuery.cpp:2352: DB::InterpreterCreateQuery::execute() @ 0x0000000014905a41 18. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88dc9 19. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 20. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 21. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 22. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 23. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 24. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 25. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 26. ? @ 0x00007fbc6213eac3 27. ? @ 0x00007fbc621d0850 2025.07.28 11:49:44.880256 [ 3285 ] {} TCPHandler: Code: 46. DB::Exception: Function with name `sumIF` does not exist. In scope SELECT t, sumIF(n, 0) FROM data GROUP BY t. (UNKNOWN_FUNCTION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&) @ 0x000000000a10182b 4. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3351: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000140362e2 5. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3838: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000014019a9e 6. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3980: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000014018e31 7. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:4304: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000014042fa7 8. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5605: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000014013749 9. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000140127f9 10. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000014011fce 11. /build/src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000001406ce8a 12. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000014973b42 13. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000001497268d 14. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:205: DB::InterpreterSelectQueryAnalyzer::getSampleBlock(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000014973e7b 15. /build/src/Interpreters/InterpreterCreateQuery.cpp:957: DB::InterpreterCreateQuery::getTablePropertiesAndNormalizeCreateQuery(DB::ASTCreateQuery&, DB::LoadingStrictnessLevel) const @ 0x00000000148f0043 16. /build/src/Interpreters/InterpreterCreateQuery.cpp:1657: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000148f901b 17. /build/src/Interpreters/InterpreterCreateQuery.cpp:2352: DB::InterpreterCreateQuery::execute() @ 0x0000000014905a41 18. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88dc9 19. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 20. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 21. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 22. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 23. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 24. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 25. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 26. ? @ 0x00007fbc6213eac3 27. ? @ 0x00007fbc621d0850 2025.07.28 11:49:46.047195 [ 4474 ] {39c6d049-540b-4f2d-b71f-5d1b7b23d73b} executeQuery: Code: 60. DB::Exception: Table test_3.buf_00097 does not exist. (UNKNOWN_TABLE) (version 25.3.6.10636.altinitytest (altinity build)) (from [::1]:33456) (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. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000a06a8eb 4. /build/src/Databases/IDatabase.cpp:41: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x0000000013dd565f 5. /build/src/Interpreters/DatabaseCatalog.cpp:442: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x00000000144f0869 6. /build/src/Interpreters/DatabaseCatalog.cpp:990: DB::DatabaseCatalog::getDatabaseAndTable(DB::StorageID const&, std::shared_ptr) const @ 0x00000000144f6e1d 7. /build/src/Interpreters/InterpreterDropQuery.cpp:146: DB::InterpreterDropQuery::executeToTableImpl(std::shared_ptr const&, DB::ASTDropQuery&, std::shared_ptr&, StrongTypedef, DB::UUIDTag>&) @ 0x00000000149140bf 8. /build/src/Interpreters/InterpreterDropQuery.cpp:118: DB::InterpreterDropQuery::executeToTable(DB::ASTDropQuery&) @ 0x00000000149137b4 9. /build/src/Interpreters/InterpreterDropQuery.cpp:91: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000014912f07 10. /build/src/Interpreters/InterpreterDropQuery.cpp:72: DB::InterpreterDropQuery::execute() @ 0x0000000014912b65 11. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88dc9 12. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 13. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 14. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 15. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 16. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 17. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 18. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 19. ? @ 0x00007fbc6213eac3 20. ? @ 0x00007fbc621d0850 2025.07.28 11:49:46.048778 [ 4454 ] {5f5b17be-75f1-473b-876b-1c1e953dcc2d} executeQuery: Code: 60. DB::Exception: Table test_3.buf_00097 does not exist. (UNKNOWN_TABLE) (version 25.3.6.10636.altinitytest (altinity build)) (from [::1]:33448) (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. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000a06a8eb 4. /build/src/Databases/IDatabase.cpp:41: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x0000000013dd565f 5. /build/src/Interpreters/DatabaseCatalog.cpp:442: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x00000000144f0869 6. /build/src/Interpreters/DatabaseCatalog.cpp:990: DB::DatabaseCatalog::getDatabaseAndTable(DB::StorageID const&, std::shared_ptr) const @ 0x00000000144f6e1d 7. /build/src/Interpreters/InterpreterDropQuery.cpp:146: DB::InterpreterDropQuery::executeToTableImpl(std::shared_ptr const&, DB::ASTDropQuery&, std::shared_ptr&, StrongTypedef, DB::UUIDTag>&) @ 0x00000000149140bf 8. /build/src/Interpreters/InterpreterDropQuery.cpp:118: DB::InterpreterDropQuery::executeToTable(DB::ASTDropQuery&) @ 0x00000000149137b4 9. /build/src/Interpreters/InterpreterDropQuery.cpp:91: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000014912f07 10. /build/src/Interpreters/InterpreterDropQuery.cpp:72: DB::InterpreterDropQuery::execute() @ 0x0000000014912b65 11. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88dc9 12. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 13. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 14. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 15. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 16. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 17. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 18. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 19. ? @ 0x00007fbc6213eac3 20. ? @ 0x00007fbc621d0850 2025.07.28 11:49:46.090568 [ 4454 ] {} TCPHandler: Code: 60. DB::Exception: Table test_3.buf_00097 does not exist. (UNKNOWN_TABLE), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000a06a8eb 4. /build/src/Databases/IDatabase.cpp:41: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x0000000013dd565f 5. /build/src/Interpreters/DatabaseCatalog.cpp:442: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x00000000144f0869 6. /build/src/Interpreters/DatabaseCatalog.cpp:990: DB::DatabaseCatalog::getDatabaseAndTable(DB::StorageID const&, std::shared_ptr) const @ 0x00000000144f6e1d 7. /build/src/Interpreters/InterpreterDropQuery.cpp:146: DB::InterpreterDropQuery::executeToTableImpl(std::shared_ptr const&, DB::ASTDropQuery&, std::shared_ptr&, StrongTypedef, DB::UUIDTag>&) @ 0x00000000149140bf 8. /build/src/Interpreters/InterpreterDropQuery.cpp:118: DB::InterpreterDropQuery::executeToTable(DB::ASTDropQuery&) @ 0x00000000149137b4 9. /build/src/Interpreters/InterpreterDropQuery.cpp:91: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000014912f07 10. /build/src/Interpreters/InterpreterDropQuery.cpp:72: DB::InterpreterDropQuery::execute() @ 0x0000000014912b65 11. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88dc9 12. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 13. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 14. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 15. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 16. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 17. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 18. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 19. ? @ 0x00007fbc6213eac3 20. ? @ 0x00007fbc621d0850 2025.07.28 11:49:46.127451 [ 4474 ] {} TCPHandler: Code: 60. DB::Exception: Table test_3.buf_00097 does not exist. (UNKNOWN_TABLE), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000a06a8eb 4. /build/src/Databases/IDatabase.cpp:41: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x0000000013dd565f 5. /build/src/Interpreters/DatabaseCatalog.cpp:442: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x00000000144f0869 6. /build/src/Interpreters/DatabaseCatalog.cpp:990: DB::DatabaseCatalog::getDatabaseAndTable(DB::StorageID const&, std::shared_ptr) const @ 0x00000000144f6e1d 7. /build/src/Interpreters/InterpreterDropQuery.cpp:146: DB::InterpreterDropQuery::executeToTableImpl(std::shared_ptr const&, DB::ASTDropQuery&, std::shared_ptr&, StrongTypedef, DB::UUIDTag>&) @ 0x00000000149140bf 8. /build/src/Interpreters/InterpreterDropQuery.cpp:118: DB::InterpreterDropQuery::executeToTable(DB::ASTDropQuery&) @ 0x00000000149137b4 9. /build/src/Interpreters/InterpreterDropQuery.cpp:91: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000014912f07 10. /build/src/Interpreters/InterpreterDropQuery.cpp:72: DB::InterpreterDropQuery::execute() @ 0x0000000014912b65 11. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88dc9 12. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 13. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 14. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 15. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 16. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 17. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 18. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 19. ? @ 0x00007fbc6213eac3 20. ? @ 0x00007fbc621d0850 2025.07.28 11:49:46.138225 [ 4749 ] {2f93676f-ece1-4f30-aea8-b1de8d119d32} executeQuery: Code: 60. DB::Exception: Table test_3.buf_00097 does not exist. (UNKNOWN_TABLE) (version 25.3.6.10636.altinitytest (altinity build)) (from [::1]:33468) (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. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000a06a8eb 4. /build/src/Databases/IDatabase.cpp:41: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x0000000013dd565f 5. /build/src/Interpreters/DatabaseCatalog.cpp:442: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x00000000144f0869 6. /build/src/Interpreters/DatabaseCatalog.cpp:990: DB::DatabaseCatalog::getDatabaseAndTable(DB::StorageID const&, std::shared_ptr) const @ 0x00000000144f6e1d 7. /build/src/Interpreters/InterpreterDropQuery.cpp:146: DB::InterpreterDropQuery::executeToTableImpl(std::shared_ptr const&, DB::ASTDropQuery&, std::shared_ptr&, StrongTypedef, DB::UUIDTag>&) @ 0x00000000149140bf 8. /build/src/Interpreters/InterpreterDropQuery.cpp:118: DB::InterpreterDropQuery::executeToTable(DB::ASTDropQuery&) @ 0x00000000149137b4 9. /build/src/Interpreters/InterpreterDropQuery.cpp:91: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000014912f07 10. /build/src/Interpreters/InterpreterDropQuery.cpp:72: DB::InterpreterDropQuery::execute() @ 0x0000000014912b65 11. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88dc9 12. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 13. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 14. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 15. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 16. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 17. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 18. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 19. ? @ 0x00007fbc6213eac3 20. ? @ 0x00007fbc621d0850 2025.07.28 11:49:46.162209 [ 4749 ] {} TCPHandler: Code: 60. DB::Exception: Table test_3.buf_00097 does not exist. (UNKNOWN_TABLE), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000a06a8eb 4. /build/src/Databases/IDatabase.cpp:41: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x0000000013dd565f 5. /build/src/Interpreters/DatabaseCatalog.cpp:442: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x00000000144f0869 6. /build/src/Interpreters/DatabaseCatalog.cpp:990: DB::DatabaseCatalog::getDatabaseAndTable(DB::StorageID const&, std::shared_ptr) const @ 0x00000000144f6e1d 7. /build/src/Interpreters/InterpreterDropQuery.cpp:146: DB::InterpreterDropQuery::executeToTableImpl(std::shared_ptr const&, DB::ASTDropQuery&, std::shared_ptr&, StrongTypedef, DB::UUIDTag>&) @ 0x00000000149140bf 8. /build/src/Interpreters/InterpreterDropQuery.cpp:118: DB::InterpreterDropQuery::executeToTable(DB::ASTDropQuery&) @ 0x00000000149137b4 9. /build/src/Interpreters/InterpreterDropQuery.cpp:91: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000014912f07 10. /build/src/Interpreters/InterpreterDropQuery.cpp:72: DB::InterpreterDropQuery::execute() @ 0x0000000014912b65 11. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88dc9 12. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 13. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 14. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 15. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 16. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 17. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 18. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 19. ? @ 0x00007fbc6213eac3 20. ? @ 0x00007fbc621d0850 2025.07.28 11:49:46.255780 [ 4462 ] {a03acb00-cc8c-49e2-95a2-798b0ba645f2} executeQuery: Code: 48. DB::Exception: Truncate is not supported by storage Buffer. (NOT_IMPLEMENTED) (version 25.3.6.10636.altinitytest (altinity build)) (from [::1]:33454) (comment: 00097_long_storage_buffer_race_condition_mt.sh) (query 4, line 2) (in query: DROP TABLE buf_00097;), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x000000000a06b56b 4. /build/src/Storages/IStorage.cpp:171: DB::IStorage::truncate(std::shared_ptr const&, std::shared_ptr const&, std::shared_ptr, DB::TableExclusiveLockHolder&) @ 0x0000000015d1ec7a 5. /build/src/Interpreters/InterpreterDropQuery.cpp:282: DB::InterpreterDropQuery::executeToTableImpl(std::shared_ptr const&, DB::ASTDropQuery&, std::shared_ptr&, StrongTypedef, DB::UUIDTag>&) @ 0x0000000014915304 6. /build/src/Interpreters/InterpreterDropQuery.cpp:118: DB::InterpreterDropQuery::executeToTable(DB::ASTDropQuery&) @ 0x00000000149137b4 7. /build/src/Interpreters/InterpreterDropQuery.cpp:91: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000014912f07 8. /build/src/Interpreters/InterpreterDropQuery.cpp:72: DB::InterpreterDropQuery::execute() @ 0x0000000014912b65 9. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88dc9 10. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 11. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 12. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 13. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 14. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 16. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 17. ? @ 0x00007fbc6213eac3 18. ? @ 0x00007fbc621d0850 2025.07.28 11:49:46.309690 [ 4462 ] {} 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. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x000000000a06b56b 4. /build/src/Storages/IStorage.cpp:171: DB::IStorage::truncate(std::shared_ptr const&, std::shared_ptr const&, std::shared_ptr, DB::TableExclusiveLockHolder&) @ 0x0000000015d1ec7a 5. /build/src/Interpreters/InterpreterDropQuery.cpp:282: DB::InterpreterDropQuery::executeToTableImpl(std::shared_ptr const&, DB::ASTDropQuery&, std::shared_ptr&, StrongTypedef, DB::UUIDTag>&) @ 0x0000000014915304 6. /build/src/Interpreters/InterpreterDropQuery.cpp:118: DB::InterpreterDropQuery::executeToTable(DB::ASTDropQuery&) @ 0x00000000149137b4 7. /build/src/Interpreters/InterpreterDropQuery.cpp:91: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000014912f07 8. /build/src/Interpreters/InterpreterDropQuery.cpp:72: DB::InterpreterDropQuery::execute() @ 0x0000000014912b65 9. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88dc9 10. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 11. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 12. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 13. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 14. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 16. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 17. ? @ 0x00007fbc6213eac3 18. ? @ 0x00007fbc621d0850 2025.07.28 11:49:47.612773 [ 3287 ] {83a0daf7-ac3a-47f0-8020-6cd5bb610359} 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. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000fccaeeb 4. /build/src/Common/ThreadPool.cpp:275: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000fccc813 5. /build/src/Common/ThreadPool.cpp:323: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fcc7bbc 6. /build/src/Common/ThreadPool.cpp:506: ThreadPoolImpl>::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000000fcc8c8d 7. /build/src/Interpreters/ConcurrentHashJoin.cpp:174: DB::ConcurrentHashJoin::ConcurrentHashJoin(std::shared_ptr, unsigned long, DB::Block const&, DB::StatsCollectingParams const&, bool) @ 0x0000000014563e16 8. /build/contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: DB::chooseJoinAlgorithm(std::shared_ptr&, DB::PreparedJoinStorage const&, DB::Block const&, DB::Block const&, DB::JoinAlgorithmSettings const&, unsigned long, std::optional) @ 0x00000000149c5837 9. /build/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) @ 0x0000000016de9821 10. /build/src/Processors/QueryPlan/Optimizations/optimizeJoin.cpp:251: DB::QueryPlanOptimizations::convertLogicalJoinToPhysical(DB::QueryPlan::Node&, std::list>&, DB::QueryPlanOptimizationSettings const&, std::optional) @ 0x0000000016eb5ce9 11. /build/src/Processors/QueryPlan/Optimizations/optimizeTree.cpp:158: DB::QueryPlanOptimizations::optimizeTreeSecondPass(DB::QueryPlanOptimizationSettings const&, DB::QueryPlan::Node&, std::list>&) @ 0x0000000016ead357 12. /build/src/Processors/QueryPlan/QueryPlan.cpp:487: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x0000000016e0055c 13. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:275: DB::InterpreterSelectQueryAnalyzer::buildQueryPipeline() @ 0x0000000014974614 14. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:242: DB::InterpreterSelectQueryAnalyzer::execute() @ 0x000000001497439e 15. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88dc9 16. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 17. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 18. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 19. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 20. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 21. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 22. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 23. ? @ 0x00007fbc6213eac3 24. ? @ 0x00007fbc621d0850 (version 25.3.6.10636.altinitytest (altinity build)) 2025.07.28 11:49:47.628672 [ 3287 ] {83a0daf7-ac3a-47f0-8020-6cd5bb610359} executeQuery: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=0, jobs=0). (CANNOT_SCHEDULE_TASK) (version 25.3.6.10636.altinitytest (altinity build)) (from [::1]:33424) (comment: 00820_multiple_joins.sql) (query 16, line 20) (in query: select t1.a, t2.b, t5.c from table1 as t1 join table2 as t2 on t1.a = t2.a join table5 as t5 on t1.a = t5.a AND t2.b = t5.b ORDER BY t1.a;), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000fccaeeb 4. /build/src/Common/ThreadPool.cpp:275: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000fccc813 5. /build/src/Common/ThreadPool.cpp:323: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fcc7bbc 6. /build/src/Common/ThreadPool.cpp:506: ThreadPoolImpl>::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000000fcc8c8d 7. /build/src/Interpreters/ConcurrentHashJoin.cpp:174: DB::ConcurrentHashJoin::ConcurrentHashJoin(std::shared_ptr, unsigned long, DB::Block const&, DB::StatsCollectingParams const&, bool) @ 0x0000000014563e16 8. /build/contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: DB::chooseJoinAlgorithm(std::shared_ptr&, DB::PreparedJoinStorage const&, DB::Block const&, DB::Block const&, DB::JoinAlgorithmSettings const&, unsigned long, std::optional) @ 0x00000000149c5837 9. /build/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) @ 0x0000000016de9821 10. /build/src/Processors/QueryPlan/Optimizations/optimizeJoin.cpp:251: DB::QueryPlanOptimizations::convertLogicalJoinToPhysical(DB::QueryPlan::Node&, std::list>&, DB::QueryPlanOptimizationSettings const&, std::optional) @ 0x0000000016eb5ce9 11. /build/src/Processors/QueryPlan/Optimizations/optimizeTree.cpp:158: DB::QueryPlanOptimizations::optimizeTreeSecondPass(DB::QueryPlanOptimizationSettings const&, DB::QueryPlan::Node&, std::list>&) @ 0x0000000016ead357 12. /build/src/Processors/QueryPlan/QueryPlan.cpp:487: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x0000000016e0055c 13. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:275: DB::InterpreterSelectQueryAnalyzer::buildQueryPipeline() @ 0x0000000014974614 14. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:242: DB::InterpreterSelectQueryAnalyzer::execute() @ 0x000000001497439e 15. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88dc9 16. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 17. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 18. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 19. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 20. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 21. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 22. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 23. ? @ 0x00007fbc6213eac3 24. ? @ 0x00007fbc621d0850 2025.07.28 11:49:47.683762 [ 3287 ] {} 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. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000fccaeeb 4. /build/src/Common/ThreadPool.cpp:275: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000fccc813 5. /build/src/Common/ThreadPool.cpp:323: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fcc7bbc 6. /build/src/Common/ThreadPool.cpp:506: ThreadPoolImpl>::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000000fcc8c8d 7. /build/src/Interpreters/ConcurrentHashJoin.cpp:174: DB::ConcurrentHashJoin::ConcurrentHashJoin(std::shared_ptr, unsigned long, DB::Block const&, DB::StatsCollectingParams const&, bool) @ 0x0000000014563e16 8. /build/contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: DB::chooseJoinAlgorithm(std::shared_ptr&, DB::PreparedJoinStorage const&, DB::Block const&, DB::Block const&, DB::JoinAlgorithmSettings const&, unsigned long, std::optional) @ 0x00000000149c5837 9. /build/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) @ 0x0000000016de9821 10. /build/src/Processors/QueryPlan/Optimizations/optimizeJoin.cpp:251: DB::QueryPlanOptimizations::convertLogicalJoinToPhysical(DB::QueryPlan::Node&, std::list>&, DB::QueryPlanOptimizationSettings const&, std::optional) @ 0x0000000016eb5ce9 11. /build/src/Processors/QueryPlan/Optimizations/optimizeTree.cpp:158: DB::QueryPlanOptimizations::optimizeTreeSecondPass(DB::QueryPlanOptimizationSettings const&, DB::QueryPlan::Node&, std::list>&) @ 0x0000000016ead357 12. /build/src/Processors/QueryPlan/QueryPlan.cpp:487: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x0000000016e0055c 13. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:275: DB::InterpreterSelectQueryAnalyzer::buildQueryPipeline() @ 0x0000000014974614 14. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:242: DB::InterpreterSelectQueryAnalyzer::execute() @ 0x000000001497439e 15. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88dc9 16. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 17. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 18. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 19. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 20. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 21. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 22. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 23. ? @ 0x00007fbc6213eac3 24. ? @ 0x00007fbc621d0850 2025.07.28 11:49:48.942779 [ 5146 ] {0434f037-e82c-48b7-aea9-4d9d5df035a4} executeQuery: Code: 131. DB::Exception: Too large string size (1095207661) in function repeat, maximum is: 1073741824: while executing 'FUNCTION repeat('0.0001048576'_String :: 1, multiply(__table1.number, multiply(__table1.number, multiply(__table1.number, 255_UInt8))) :: 0) -> repeat('0.0001048576'_String, multiply(__table1.number, multiply(__table1.number, multiply(__table1.number, 255_UInt8)))) String : 2'. (TOO_LARGE_STRING_SIZE) (version 25.3.6.10636.altinitytest (altinity build)) (from [::1]:33660) (comment: 01404_roundUpToPowerOfTwoOrZero_safety.sql) (query 1, line 1) (in query: -- repeat() with this length and this number of rows will allocation huge enough region (MSB set), -- which will cause roundUpToPowerOfTwoOrZero() returns 0 for such allocation (before the fix), -- and later repeat() will try to use this memory and will got SIGSEGV. SELECT repeat('0.0001048576', number * (number * (number * 255))) FROM numbers(65535);), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, unsigned long&, unsigned long const&) @ 0x000000000aac40ab 4. /build/src/Functions/repeat.cpp:36: auto DB::(anonymous namespace)::FunctionRepeat::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda1'(auto const&)::operator()>(auto const&) const @ 0x000000000e6283e8 5. /build/src/Functions/castTypeToEither.h:12: DB::(anonymous namespace)::FunctionRepeat::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000e6207fe 6. /build/src/Functions/IFunctionAdaptors.cpp:10: DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000012d995fa 7. /build/src/Functions/IFunction.cpp:353: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d93b52 8. /build/src/Functions/IFunction.cpp:420: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d95059 9. /build/src/Functions/IFunction.cpp:498: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d95c72 10. /build/src/Interpreters/ExpressionActions.cpp:636: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x00000000145176f3 11. /build/src/Processors/Transforms/ExpressionTransform.cpp:25: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x0000000016c0b34c 12. /build/src/Processors/ISimpleTransform.h:33: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000011a9a453 13. /build/src/Processors/ISimpleTransform.cpp:89: DB::ISimpleTransform::work() @ 0x000000001699fca0 14. /build/src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x00000000169bd00f 15. /build/src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x00000000169b2105 16. /build/src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeSingleThread(unsigned long) @ 0x00000000169b23be 17. /build/src/Processors/Executors/PipelineExecutor.cpp:454: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x00000000169b0be7 18. /build/src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x00000000169b03f4 19. /build/src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:se190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169bfeab 20. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc3d92 21. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fcca080 22. ? @ 0x00007fbc6213eac3 23. ? @ 0x00007fbc621d0850 2025.07.28 11:49:49.001155 [ 5146 ] {} TCPHandler: Code: 131. DB::Exception: Too large string size (1095207661) in function repeat, maximum is: 1073741824: while executing 'FUNCTION repeat('0.0001048576'_String :: 1, multiply(__table1.number, multiply(__table1.number, multiply(__table1.number, 255_UInt8))) :: 0) -> repeat('0.0001048576'_String, multiply(__table1.number, multiply(__table1.number, multiply(__table1.number, 255_UInt8)))) String : 2'. (TOO_LARGE_STRING_SIZE), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, unsigned long&, unsigned long const&) @ 0x000000000aac40ab 4. /build/src/Functions/repeat.cpp:36: auto DB::(anonymous namespace)::FunctionRepeat::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda1'(auto const&)::operator()>(auto const&) const @ 0x000000000e6283e8 5. /build/src/Functions/castTypeToEither.h:12: DB::(anonymous namespace)::FunctionRepeat::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000e6207fe 6. /build/src/Functions/IFunctionAdaptors.cpp:10: DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000012d995fa 7. /build/src/Functions/IFunction.cpp:353: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d93b52 8. /build/src/Functions/IFunction.cpp:420: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d95059 9. /build/src/Functions/IFunction.cpp:498: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d95c72 10. /build/src/Interpreters/ExpressionActions.cpp:636: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x00000000145176f3 11. /build/src/Processors/Transforms/ExpressionTransform.cpp:25: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x0000000016c0b34c 12. /build/src/Processors/ISimpleTransform.h:33: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000011a9a453 13. /build/src/Processors/ISimpleTransform.cpp:89: DB::ISimpleTransform::work() @ 0x000000001699fca0 14. /build/src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x00000000169bd00f 15. /build/src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x00000000169b2105 16. /build/src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeSingleThread(unsigned long) @ 0x00000000169b23be 17. /build/src/Processors/Executors/PipelineExecutor.cpp:454: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x00000000169b0be7 18. /build/src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x00000000169b03f4 19. /build/src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:se190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169bfeab 20. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc3d92 21. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fcca080 22. ? @ 0x00007fbc6213eac3 23. ? @ 0x00007fbc621d0850 Job's origin stack trace: 0. /build/src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000000fc33b84 1. /build/src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000000fcc2ea7 2. /build/src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fcc535c 3. /build/src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000000fcc584d 4. /build/src/Common/ThreadPool.h:279: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x00000000169bf193 5. /build/src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x00000000169bf518 6. /build/src/Server/TCPHandler.cpp:1237: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x00000000168f1525 7. /build/src/Server/TCPHandler.cpp:678: DB::TCPHandler::runImpl() @ 0x00000000168e68e5 8. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 9. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 10. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 11. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 12. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 13. ? @ 0x00007fbc6213eac3 14. ? @ 0x00007fbc621d0850 2025.07.28 11:49:51.073969 [ 4900 ] {} 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. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception>&, String>(int, FormatStringHelperImpl>&>::type, std::type_identity::type>, std::basic_string_view>&, String&&) @ 0x000000001385a5eb 4. /build/src/Access/SettingsConstraints.cpp:376: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000013859b18 5. /build/src/Access/SettingsConstraints.cpp:300: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000013858faf 6. /build/src/Access/SettingsConstraints.cpp:209: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000013859223 7. /build/src/Interpreters/Context.cpp:2690: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000014436134 8. /build/src/Interpreters/Context.cpp:2729: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x000000001443662b 9. /build/src/Server/HTTPHandler.cpp:457: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000001686d165 10. /build/src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x0000000016870807 11. /build/src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x0000000016907e99 12. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 13. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 14. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 15. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 16. ? @ 0x00007fbc6213eac3 17. ? @ 0x00007fbc621d0850 (version 25.3.6.10636.altinitytest (altinity build)) 2025.07.28 11:49:51.149569 [ 5825 ] {db404dff-e040-4f17-937b-1fd0605e04ab} 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.6.10636.altinitytest (altinity build)) (from [::1]:33858) (comment: 02722_database_filesystem.sh) (query 1, line 1) (in query: SELECT COUNT(*) FROM test_fl5dx20u_test1.`tmp_numbers_*.csv`;), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x000000000a080b2b 4. /build/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&) @ 0x0000000015d87050 5. /build/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&) @ 0x0000000015d8741c 6. /build/src/Storages/StorageFile.cpp:1122: DB::StorageFile::setStorageMetadata(DB::StorageFile::CommonArguments) @ 0x0000000015d88292 7. /build/src/Storages/StorageFile.cpp:1063: DB::StorageFile::StorageFile(String const&, String const&, DB::StorageFile::CommonArguments) @ 0x0000000015d89a79 8. /build/src/Storages/StorageFile.cpp:1067: DB::StorageFile::StorageFile(String const&, String const&, bool, DB::StorageFile::CommonArguments) @ 0x0000000015d8a0dc 9. /build/contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: std::shared_ptr std::allocate_shared[abi:se190107], String const&, String, bool, DB::StorageFile::CommonArguments&, 0>(std::allocator const&, String const&, String&&, bool&&, DB::StorageFile::CommonArguments&) @ 0x00000000118256ca 10. /build/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 @ 0x0000000011823998 11. /build/src/TableFunctions/ITableFunctionFileLike.cpp:96: DB::ITableFunctionFileLike::executeImpl(std::shared_ptr const&, std::shared_ptr, String const&, DB::ColumnsDescription, bool) const @ 0x000000001182689c 12. /build/src/TableFunctions/ITableFunction.cpp:36: DB::ITableFunction::execute(std::shared_ptr const&, std::shared_ptr, String const&, DB::ColumnsDescription, bool, bool) const @ 0x00000000131e9fc3 13. /build/src/Databases/DatabaseFilesystem.cpp:161: DB::DatabaseFilesystem::getTableImpl(String const&, std::shared_ptr, bool) const @ 0x0000000013d6424e 14. /build/src/Databases/DatabaseFilesystem.cpp:180: DB::DatabaseFilesystem::tryGetTable(String const&, std::shared_ptr) const @ 0x0000000013d647a4 15. /build/src/Interpreters/DatabaseCatalog.cpp:451: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x00000000144f19c8 16. /build/src/Interpreters/DatabaseCatalog.cpp:984: DB::DatabaseCatalog::tryGetTable(DB::StorageID const&, std::shared_ptr) const @ 0x00000000144f6b77 17. /build/src/Analyzer/Resolve/IdentifierResolver.cpp:177: DB::IdentifierResolver::tryResolveTableIdentifierFromDatabaseCatalog(DB::Identifier const&, std::shared_ptr const&) @ 0x00000000142b9931 18. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:1550: DB::QueryAnalyzer::tryResolveIdentifier(DB::IdentifierLookup const&, DB::IdentifierResolveScope&, DB::IdentifierResolveContext) @ 0x00000000140299a0 19. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:4365: DB::QueryAnalyzer::initializeQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000014043a79 20. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5594: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000140135fb 21. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000140127f9 22. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000014011fce 23. /build/src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000001406ce8a 24. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000014973b42 25. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000001497268d 26. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000014974d24 27. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001492924b 28. /build/src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88641 29. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 30. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 31. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 2025.07.28 11:49:51.162334 [ 5825 ] {} 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. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x000000000a080b2b 4. /build/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&) @ 0x0000000015d87050 5. /build/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&) @ 0x0000000015d8741c 6. /build/src/Storages/StorageFile.cpp:1122: DB::StorageFile::setStorageMetadata(DB::StorageFile::CommonArguments) @ 0x0000000015d88292 7. /build/src/Storages/StorageFile.cpp:1063: DB::StorageFile::StorageFile(String const&, String const&, DB::StorageFile::CommonArguments) @ 0x0000000015d89a79 8. /build/src/Storages/StorageFile.cpp:1067: DB::StorageFile::StorageFile(String const&, String const&, bool, DB::StorageFile::CommonArguments) @ 0x0000000015d8a0dc 9. /build/contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: std::shared_ptr std::allocate_shared[abi:se190107], String const&, String, bool, DB::StorageFile::CommonArguments&, 0>(std::allocator const&, String const&, String&&, bool&&, DB::StorageFile::CommonArguments&) @ 0x00000000118256ca 10. /build/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 @ 0x0000000011823998 11. /build/src/TableFunctions/ITableFunctionFileLike.cpp:96: DB::ITableFunctionFileLike::executeImpl(std::shared_ptr const&, std::shared_ptr, String const&, DB::ColumnsDescription, bool) const @ 0x000000001182689c 12. /build/src/TableFunctions/ITableFunction.cpp:36: DB::ITableFunction::execute(std::shared_ptr const&, std::shared_ptr, String const&, DB::ColumnsDescription, bool, bool) const @ 0x00000000131e9fc3 13. /build/src/Databases/DatabaseFilesystem.cpp:161: DB::DatabaseFilesystem::getTableImpl(String const&, std::shared_ptr, bool) const @ 0x0000000013d6424e 14. /build/src/Databases/DatabaseFilesystem.cpp:180: DB::DatabaseFilesystem::tryGetTable(String const&, std::shared_ptr) const @ 0x0000000013d647a4 15. /build/src/Interpreters/DatabaseCatalog.cpp:451: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x00000000144f19c8 16. /build/src/Interpreters/DatabaseCatalog.cpp:984: DB::DatabaseCatalog::tryGetTable(DB::StorageID const&, std::shared_ptr) const @ 0x00000000144f6b77 17. /build/src/Analyzer/Resolve/IdentifierResolver.cpp:177: DB::IdentifierResolver::tryResolveTableIdentifierFromDatabaseCatalog(DB::Identifier const&, std::shared_ptr const&) @ 0x00000000142b9931 18. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:1550: DB::QueryAnalyzer::tryResolveIdentifier(DB::IdentifierLookup const&, DB::IdentifierResolveScope&, DB::IdentifierResolveContext) @ 0x00000000140299a0 19. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:4365: DB::QueryAnalyzer::initializeQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000014043a79 20. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5594: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000140135fb 21. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000140127f9 22. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000014011fce 23. /build/src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000001406ce8a 24. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000014973b42 25. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000001497268d 26. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000014974d24 27. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001492924b 28. /build/src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88641 29. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 30. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 31. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 2025.07.28 11:49:51.472646 [ 4446 ] {ad97bf1c-e28a-4525-a1a5-86ffa7b5e69d} 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.6.10636.altinitytest (altinity build)) (from [::1]:33612) (comment: 01016_uniqCombined64.sql) (query 2, line 9) (in query: SELECT uniqCombined64(number) FROM numbers(1e7);), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.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&&) @ 0x000000000fc1a9d9 4. /build/src/Common/MemoryTracker.cpp:298: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000000fc19854 5. /build/src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000000fc19293 6. /build/src/Interpreters/Aggregator.cpp:1835: DB::Aggregator::checkLimits(unsigned long, bool&) const @ 0x0000000014589d8c 7. /build/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 @ 0x0000000014593bec 8. /build/src/Processors/Transforms/AggregatingTransform.cpp:690: DB::AggregatingTransform::consume(DB::Chunk) @ 0x0000000016bf205c 9. /build/src/Processors/Transforms/AggregatingTransform.cpp:648: DB::AggregatingTransform::work() @ 0x0000000016bef6c6 10. /build/src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x00000000169bd00f 11. /build/src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x00000000169b2105 12. /build/src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeSingleThread(unsigned long) @ 0x00000000169b23be 13. /build/src/Processors/Executors/PipelineExecutor.cpp:416: void std::__function::__policy_invoker::__call_impl[abi:se190107]>(std::__function::__policy_storage const*) @ 0x00000000169b2e3f 14. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc6653 15. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000000fccc4c3 16. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc3d92 17. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fcca080 18. ? @ 0x00007fbc6213eac3 19. ? @ 0x00007fbc621d0850 2025.07.28 11:49:51.569781 [ 4446 ] {} 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. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.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&&) @ 0x000000000fc1a9d9 4. /build/src/Common/MemoryTracker.cpp:298: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000000fc19854 5. /build/src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000000fc19293 6. /build/src/Interpreters/Aggregator.cpp:1835: DB::Aggregator::checkLimits(unsigned long, bool&) const @ 0x0000000014589d8c 7. /build/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 @ 0x0000000014593bec 8. /build/src/Processors/Transforms/AggregatingTransform.cpp:690: DB::AggregatingTransform::consume(DB::Chunk) @ 0x0000000016bf205c 9. /build/src/Processors/Transforms/AggregatingTransform.cpp:648: DB::AggregatingTransform::work() @ 0x0000000016bef6c6 10. /build/src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x00000000169bd00f 11. /build/src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x00000000169b2105 12. /build/src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeSingleThread(unsigned long) @ 0x00000000169b23be 13. /build/src/Processors/Executors/PipelineExecutor.cpp:416: void std::__function::__policy_invoker::__call_impl[abi:se190107]>(std::__function::__policy_storage const*) @ 0x00000000169b2e3f 14. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc6653 15. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000000fccc4c3 16. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc3d92 17. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fcca080 18. ? @ 0x00007fbc6213eac3 19. ? @ 0x00007fbc621d0850 Job's origin stack trace: 0. /build/src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000000fc33b84 1. /build/src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000000fcc2ea7 2. /build/src/Common/ThreadPool.cpp:401: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fcc7f1c 3. /build/src/Common/ThreadPool.cpp:494: ThreadPoolImpl>::scheduleOrThrowOnError(std::function, Priority) @ 0x000000000fcc7a0e 4. /build/src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::spawnThreadsImpl() @ 0x00000000169b2c0c 5. /build/src/Processors/Executors/PipelineExecutor.cpp:394: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x00000000169b0ba7 6. /build/src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x00000000169b03f4 7. /build/src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:se190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169bfeab 8. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc3d92 9. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fcca080 10. ? @ 0x00007fbc6213eac3 11. ? @ 0x00007fbc621d0850 Job's origin stack trace: 0. /build/src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000000fc33b84 1. /build/src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000000fcc2ea7 2. /build/src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fcc535c 3. /build/src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000000fcc584d 4. /build/src/Common/ThreadPool.h:279: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x00000000169bf193 5. /build/src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x00000000169bf518 6. /build/src/Server/TCPHandler.cpp:1237: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x00000000168f1525 7. /build/src/Server/TCPHandler.cpp:678: DB::TCPHandler::runImpl() @ 0x00000000168e68e5 8. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 9. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 10. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 11. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 12. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 13. ? @ 0x00007fbc6213eac3 14. ? @ 0x00007fbc621d0850 2025.07.28 11:49:51.646935 [ 4508 ] {f414456a-6a5b-4492-ba3b-bdcaf887edaf} executeQuery: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=5, jobs=0): While executing MergeTreeSelect(pool: ReadPoolInOrder, algorithm: InOrder). (CANNOT_SCHEDULE_TASK) (version 25.3.6.10636.altinitytest (altinity build)) (from [::1]:33772) (comment: 03289_tuple_element_to_subcolumn.sql) (query 8, line 21) (in query: SELECT (tupleElement(t1, 'a'), tupleElement(t1, 'b')) FROM t_tuple_elem ORDER BY ALL;), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000fccaeeb 4. /build/src/Common/ThreadPool.cpp:275: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000fccc813 5. /build/src/Common/ThreadPool.cpp:323: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fcc7bbc 6. /build/src/Common/ThreadPool.cpp:494: ThreadPoolImpl>::scheduleOrThrowOnError(std::function, Priority) @ 0x000000000fcc7a0e 7. /build/src/Common/threadPoolCallbackRunner.h:52: std::future> std::__function::__policy_invoker> (DB::MergeTreeMarksLoader::loadMarksAsync()::$_0&&, Priority)>::__call_impl[abi:se190107]> (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&&) @ 0x0000000016474731 8. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000016471940 9. /build/src/Storages/MergeTree/MergeTreeMarksLoader.cpp:83: DB::MergeTreeMarksLoader::startAsyncLoad() @ 0x000000001647173f 10. /build/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) @ 0x000000001648df37 11. /build/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&&) @ 0x00000000163c608d 12. /build/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 @ 0x00000000163c27d4 13. /build/src/Storages/MergeTree/MergeTreeReadTask.cpp:60: DB::MergeTreeReadTask::createReaders(std::shared_ptr const&, DB::MergeTreeReadTask::Extras const&, DB::MarkRanges const&) @ 0x00000000164b5386 14. /build/src/Storages/MergeTree/MergeTreeReadPoolBase.cpp:274: DB::MergeTreeReadPoolBase::createTask(std::shared_ptr, DB::MarkRanges, DB::MergeTreeReadTask*) const @ 0x0000000016e53b1f 15. /build/src/Storages/MergeTree/MergeTreeReadPoolInOrder.cpp:74: DB::MergeTreeReadPoolInOrder::getTask(unsigned long, DB::MergeTreeReadTask*) @ 0x0000000016e7808a 16. /build/src/Storages/MergeTree/MergeTreeSelectProcessor.cpp:191: DB::MergeTreeSelectProcessor::read() @ 0x00000000164c0b40 17. /build/src/Storages/MergeTree/MergeTreeSource.cpp:229: DB::MergeTreeSource::tryGenerate() @ 0x0000000016e43d69 18. /build/src/Processors/ISource.cpp:108: DB::ISource::work() @ 0x00000000169a21e7 19. /build/src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x00000000169bd00f 20. /build/src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x00000000169b2105 21. /build/src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeSingleThread(unsigned long) @ 0x00000000169b23be 22. /build/src/Processors/Executors/PipelineExecutor.cpp:416: void std::__function::__policy_invoker::__call_impl[abi:se190107]>(std::__function::__policy_storage const*) @ 0x00000000169b2e3f 23. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc6653 24. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000000fccc4c3 25. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc3d92 26. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fcca080 27. ? @ 0x00007fbc6213eac3 28. ? @ 0x00007fbc621d0850 2025.07.28 11:49:51.651118 [ 5951 ] {7d3ee762-c172-4a73-bf29-8b5aa8758d50} executeQuery: Code: 481. DB::Exception: File is not inside /var/lib/clickhouse/user_files/. (PATH_ACCESS_DENIED) (version 25.3.6.10636.altinitytest (altinity build)) (from [::1]:34894) (comment: 02722_database_filesystem.sh) (query 1, line 1) (in query: SELECT COUNT(*) FROM test_fl5dx20u_test1.`../tmp.csv`;), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000a9b78ab 4. /build/src/Databases/DatabaseFilesystem.cpp:91: DB::DatabaseFilesystem::checkTableFilePath(String const&, std::shared_ptr, bool) const @ 0x0000000013d639dc 5. /build/src/Databases/DatabaseFilesystem.cpp:151: DB::DatabaseFilesystem::getTableImpl(String const&, std::shared_ptr, bool) const @ 0x0000000013d64038 6. /build/src/Databases/DatabaseFilesystem.cpp:180: DB::DatabaseFilesystem::tryGetTable(String const&, std::shared_ptr) const @ 0x0000000013d647a4 7. /build/src/Interpreters/DatabaseCatalog.cpp:451: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x00000000144f19c8 8. /build/src/Interpreters/DatabaseCatalog.cpp:984: DB::DatabaseCatalog::tryGetTable(DB::StorageID const&, std::shared_ptr) const @ 0x00000000144f6b77 9. /build/src/Analyzer/Resolve/IdentifierResolver.cpp:177: DB::IdentifierResolver::tryResolveTableIdentifierFromDatabaseCatalog(DB::Identifier const&, std::shared_ptr const&) @ 0x00000000142b9931 10. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:1550: DB::QueryAnalyzer::tryResolveIdentifier(DB::IdentifierLookup const&, DB::IdentifierResolveScope&, DB::IdentifierResolveContext) @ 0x00000000140299a0 11. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:4365: DB::QueryAnalyzer::initializeQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000014043a79 12. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5594: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000140135fb 13. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000140127f9 14. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000014011fce 15. /build/src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000001406ce8a 16. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000014973b42 17. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000001497268d 18. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000014974d24 19. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001492924b 20. /build/src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88641 21. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 22. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 23. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 24. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 25. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 26. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 27. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 28. ? @ 0x00007fbc6213eac3 29. ? @ 0x00007fbc621d0850 2025.07.28 11:49:51.672532 [ 5951 ] {} 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. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000a9b78ab 4. /build/src/Databases/DatabaseFilesystem.cpp:91: DB::DatabaseFilesystem::checkTableFilePath(String const&, std::shared_ptr, bool) const @ 0x0000000013d639dc 5. /build/src/Databases/DatabaseFilesystem.cpp:151: DB::DatabaseFilesystem::getTableImpl(String const&, std::shared_ptr, bool) const @ 0x0000000013d64038 6. /build/src/Databases/DatabaseFilesystem.cpp:180: DB::DatabaseFilesystem::tryGetTable(String const&, std::shared_ptr) const @ 0x0000000013d647a4 7. /build/src/Interpreters/DatabaseCatalog.cpp:451: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x00000000144f19c8 8. /build/src/Interpreters/DatabaseCatalog.cpp:984: DB::DatabaseCatalog::tryGetTable(DB::StorageID const&, std::shared_ptr) const @ 0x00000000144f6b77 9. /build/src/Analyzer/Resolve/IdentifierResolver.cpp:177: DB::IdentifierResolver::tryResolveTableIdentifierFromDatabaseCatalog(DB::Identifier const&, std::shared_ptr const&) @ 0x00000000142b9931 10. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:1550: DB::QueryAnalyzer::tryResolveIdentifier(DB::IdentifierLookup const&, DB::IdentifierResolveScope&, DB::IdentifierResolveContext) @ 0x00000000140299a0 11. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:4365: DB::QueryAnalyzer::initializeQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000014043a79 12. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5594: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000140135fb 13. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000140127f9 14. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000014011fce 15. /build/src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000001406ce8a 16. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000014973b42 17. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000001497268d 18. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000014974d24 19. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001492924b 20. /build/src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88641 21. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 22. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 23. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 24. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 25. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 26. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 27. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 28. ? @ 0x00007fbc6213eac3 29. ? @ 0x00007fbc621d0850 2025.07.28 11:49:51.683185 [ 4508 ] {} TCPHandler: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=5, jobs=0): While executing MergeTreeSelect(pool: ReadPoolInOrder, algorithm: InOrder). (CANNOT_SCHEDULE_TASK), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000fccaeeb 4. /build/src/Common/ThreadPool.cpp:275: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000fccc813 5. /build/src/Common/ThreadPool.cpp:323: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fcc7bbc 6. /build/src/Common/ThreadPool.cpp:494: ThreadPoolImpl>::scheduleOrThrowOnError(std::function, Priority) @ 0x000000000fcc7a0e 7. /build/src/Common/threadPoolCallbackRunner.h:52: std::future> std::__function::__policy_invoker> (DB::MergeTreeMarksLoader::loadMarksAsync()::$_0&&, Priority)>::__call_impl[abi:se190107]> (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&&) @ 0x0000000016474731 8. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000016471940 9. /build/src/Storages/MergeTree/MergeTreeMarksLoader.cpp:83: DB::MergeTreeMarksLoader::startAsyncLoad() @ 0x000000001647173f 10. /build/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) @ 0x000000001648df37 11. /build/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&&) @ 0x00000000163c608d 12. /build/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 @ 0x00000000163c27d4 13. /build/src/Storages/MergeTree/MergeTreeReadTask.cpp:60: DB::MergeTreeReadTask::createReaders(std::shared_ptr const&, DB::MergeTreeReadTask::Extras const&, DB::MarkRanges const&) @ 0x00000000164b5386 14. /build/src/Storages/MergeTree/MergeTreeReadPoolBase.cpp:274: DB::MergeTreeReadPoolBase::createTask(std::shared_ptr, DB::MarkRanges, DB::MergeTreeReadTask*) const @ 0x0000000016e53b1f 15. /build/src/Storages/MergeTree/MergeTreeReadPoolInOrder.cpp:74: DB::MergeTreeReadPoolInOrder::getTask(unsigned long, DB::MergeTreeReadTask*) @ 0x0000000016e7808a 16. /build/src/Storages/MergeTree/MergeTreeSelectProcessor.cpp:191: DB::MergeTreeSelectProcessor::read() @ 0x00000000164c0b40 17. /build/src/Storages/MergeTree/MergeTreeSource.cpp:229: DB::MergeTreeSource::tryGenerate() @ 0x0000000016e43d69 18. /build/src/Processors/ISource.cpp:108: DB::ISource::work() @ 0x00000000169a21e7 19. /build/src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x00000000169bd00f 20. /build/src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x00000000169b2105 21. /build/src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeSingleThread(unsigned long) @ 0x00000000169b23be 22. /build/src/Processors/Executors/PipelineExecutor.cpp:416: void std::__function::__policy_invoker::__call_impl[abi:se190107]>(std::__function::__policy_storage const*) @ 0x00000000169b2e3f 23. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc6653 24. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000000fccc4c3 25. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc3d92 26. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fcca080 27. ? @ 0x00007fbc6213eac3 28. ? @ 0x00007fbc621d0850 Job's origin stack trace: 0. /build/src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000000fc33b84 1. /build/src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000000fcc2ea7 2. /build/src/Common/ThreadPool.cpp:401: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fcc7f1c 3. /build/src/Common/ThreadPool.cpp:494: ThreadPoolImpl>::scheduleOrThrowOnError(std::function, Priority) @ 0x000000000fcc7a0e 4. /build/src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::spawnThreadsImpl() @ 0x00000000169b2c0c 5. /build/src/Processors/Executors/PipelineExecutor.cpp:394: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x00000000169b0ba7 6. /build/src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x00000000169b03f4 7. /build/src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:se190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169bfeab 8. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc3d92 9. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fcca080 10. ? @ 0x00007fbc6213eac3 11. ? @ 0x00007fbc621d0850 Job's origin stack trace: 0. /build/src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000000fc33b84 1. /build/src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000000fcc2ea7 2. /build/src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fcc535c 3. /build/src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000000fcc584d 4. /build/src/Common/ThreadPool.h:279: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x00000000169bf193 5. /build/src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x00000000169bf518 6. /build/src/Server/TCPHandler.cpp:1237: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x00000000168f1525 7. /build/src/Server/TCPHandler.cpp:678: DB::TCPHandler::runImpl() @ 0x00000000168e68e5 8. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 9. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 10. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 11. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 12. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 13. ? @ 0x00007fbc6213eac3 14. ? @ 0x00007fbc621d0850 2025.07.28 11:49:51.926528 [ 4508 ] {7f9558f8-3c96-46f2-ac3d-0d005b2814b8} executeQuery: Code: 481. DB::Exception: File is not inside /var/lib/clickhouse/user_files/. (PATH_ACCESS_DENIED) (version 25.3.6.10636.altinitytest (altinity build)) (from [::1]:34924) (comment: 02722_database_filesystem.sh) (query 1, line 1) (in query: SELECT COUNT(*) FROM test_fl5dx20u_test1.`/tmp/tmp.csv`;), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000a9b78ab 4. /build/src/Databases/DatabaseFilesystem.cpp:91: DB::DatabaseFilesystem::checkTableFilePath(String const&, std::shared_ptr, bool) const @ 0x0000000013d639dc 5. /build/src/Databases/DatabaseFilesystem.cpp:151: DB::DatabaseFilesystem::getTableImpl(String const&, std::shared_ptr, bool) const @ 0x0000000013d64038 6. /build/src/Databases/DatabaseFilesystem.cpp:180: DB::DatabaseFilesystem::tryGetTable(String const&, std::shared_ptr) const @ 0x0000000013d647a4 7. /build/src/Interpreters/DatabaseCatalog.cpp:451: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x00000000144f19c8 8. /build/src/Interpreters/DatabaseCatalog.cpp:984: DB::DatabaseCatalog::tryGetTable(DB::StorageID const&, std::shared_ptr) const @ 0x00000000144f6b77 9. /build/src/Analyzer/Resolve/IdentifierResolver.cpp:177: DB::IdentifierResolver::tryResolveTableIdentifierFromDatabaseCatalog(DB::Identifier const&, std::shared_ptr const&) @ 0x00000000142b9931 10. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:1550: DB::QueryAnalyzer::tryResolveIdentifier(DB::IdentifierLookup const&, DB::IdentifierResolveScope&, DB::IdentifierResolveContext) @ 0x00000000140299a0 11. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:4365: DB::QueryAnalyzer::initializeQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000014043a79 12. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5594: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000140135fb 13. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000140127f9 14. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000014011fce 15. /build/src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000001406ce8a 16. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000014973b42 17. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000001497268d 18. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000014974d24 19. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001492924b 20. /build/src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88641 21. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 22. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 23. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 24. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 25. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 26. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 27. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 28. ? @ 0x00007fbc6213eac3 29. ? @ 0x00007fbc621d0850 2025.07.28 11:49:51.930450 [ 4508 ] {} 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. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000a9b78ab 4. /build/src/Databases/DatabaseFilesystem.cpp:91: DB::DatabaseFilesystem::checkTableFilePath(String const&, std::shared_ptr, bool) const @ 0x0000000013d639dc 5. /build/src/Databases/DatabaseFilesystem.cpp:151: DB::DatabaseFilesystem::getTableImpl(String const&, std::shared_ptr, bool) const @ 0x0000000013d64038 6. /build/src/Databases/DatabaseFilesystem.cpp:180: DB::DatabaseFilesystem::tryGetTable(String const&, std::shared_ptr) const @ 0x0000000013d647a4 7. /build/src/Interpreters/DatabaseCatalog.cpp:451: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x00000000144f19c8 8. /build/src/Interpreters/DatabaseCatalog.cpp:984: DB::DatabaseCatalog::tryGetTable(DB::StorageID const&, std::shared_ptr) const @ 0x00000000144f6b77 9. /build/src/Analyzer/Resolve/IdentifierResolver.cpp:177: DB::IdentifierResolver::tryResolveTableIdentifierFromDatabaseCatalog(DB::Identifier const&, std::shared_ptr const&) @ 0x00000000142b9931 10. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:1550: DB::QueryAnalyzer::tryResolveIdentifier(DB::IdentifierLookup const&, DB::IdentifierResolveScope&, DB::IdentifierResolveContext) @ 0x00000000140299a0 11. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:4365: DB::QueryAnalyzer::initializeQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000014043a79 12. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5594: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000140135fb 13. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000140127f9 14. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000014011fce 15. /build/src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000001406ce8a 16. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000014973b42 17. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000001497268d 18. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000014974d24 19. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001492924b 20. /build/src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88641 21. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 22. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 23. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 24. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 25. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 26. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 27. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 28. ? @ 0x00007fbc6213eac3 29. ? @ 0x00007fbc621d0850 2025.07.28 11:49:52.198328 [ 4963 ] {3c99172d-51a7-4cd9-a8fd-658b27ff8084} executeQuery: Code: 481. DB::Exception: File is not inside /var/lib/clickhouse/user_files/. (PATH_ACCESS_DENIED) (version 25.3.6.10636.altinitytest (altinity build)) (from [::1]:34960) (comment: 02722_database_filesystem.sh) (query 1, line 1) (in query: SELECT COUNT(*) FROM test_fl5dx20u_test1.`../*/tmp_numbers_*.csv`;), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000a9b78ab 4. /build/src/Databases/DatabaseFilesystem.cpp:91: DB::DatabaseFilesystem::checkTableFilePath(String const&, std::shared_ptr, bool) const @ 0x0000000013d639dc 5. /build/src/Databases/DatabaseFilesystem.cpp:151: DB::DatabaseFilesystem::getTableImpl(String const&, std::shared_ptr, bool) const @ 0x0000000013d64038 6. /build/src/Databases/DatabaseFilesystem.cpp:180: DB::DatabaseFilesystem::tryGetTable(String const&, std::shared_ptr) const @ 0x0000000013d647a4 7. /build/src/Interpreters/DatabaseCatalog.cpp:451: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x00000000144f19c8 8. /build/src/Interpreters/DatabaseCatalog.cpp:984: DB::DatabaseCatalog::tryGetTable(DB::StorageID const&, std::shared_ptr) const @ 0x00000000144f6b77 9. /build/src/Analyzer/Resolve/IdentifierResolver.cpp:177: DB::IdentifierResolver::tryResolveTableIdentifierFromDatabaseCatalog(DB::Identifier const&, std::shared_ptr const&) @ 0x00000000142b9931 10. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:1550: DB::QueryAnalyzer::tryResolveIdentifier(DB::IdentifierLookup const&, DB::IdentifierResolveScope&, DB::IdentifierResolveContext) @ 0x00000000140299a0 11. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:4365: DB::QueryAnalyzer::initializeQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000014043a79 12. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5594: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000140135fb 13. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000140127f9 14. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000014011fce 15. /build/src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000001406ce8a 16. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000014973b42 17. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000001497268d 18. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000014974d24 19. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001492924b 20. /build/src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88641 21. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 22. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 23. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 24. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 25. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 26. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 27. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 28. ? @ 0x00007fbc6213eac3 29. ? @ 0x00007fbc621d0850 2025.07.28 11:49:52.210774 [ 4963 ] {} 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. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000a9b78ab 4. /build/src/Databases/DatabaseFilesystem.cpp:91: DB::DatabaseFilesystem::checkTableFilePath(String const&, std::shared_ptr, bool) const @ 0x0000000013d639dc 5. /build/src/Databases/DatabaseFilesystem.cpp:151: DB::DatabaseFilesystem::getTableImpl(String const&, std::shared_ptr, bool) const @ 0x0000000013d64038 6. /build/src/Databases/DatabaseFilesystem.cpp:180: DB::DatabaseFilesystem::tryGetTable(String const&, std::shared_ptr) const @ 0x0000000013d647a4 7. /build/src/Interpreters/DatabaseCatalog.cpp:451: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x00000000144f19c8 8. /build/src/Interpreters/DatabaseCatalog.cpp:984: DB::DatabaseCatalog::tryGetTable(DB::StorageID const&, std::shared_ptr) const @ 0x00000000144f6b77 9. /build/src/Analyzer/Resolve/IdentifierResolver.cpp:177: DB::IdentifierResolver::tryResolveTableIdentifierFromDatabaseCatalog(DB::Identifier const&, std::shared_ptr const&) @ 0x00000000142b9931 10. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:1550: DB::QueryAnalyzer::tryResolveIdentifier(DB::IdentifierLookup const&, DB::IdentifierResolveScope&, DB::IdentifierResolveContext) @ 0x00000000140299a0 11. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:4365: DB::QueryAnalyzer::initializeQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000014043a79 12. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5594: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000140135fb 13. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000140127f9 14. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000014011fce 15. /build/src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000001406ce8a 16. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000014973b42 17. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000001497268d 18. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000014974d24 19. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001492924b 20. /build/src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88641 21. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 22. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 23. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 24. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 25. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 26. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 27. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 28. ? @ 0x00007fbc6213eac3 29. ? @ 0x00007fbc621d0850 2025.07.28 11:49:52.399722 [ 5980 ] {99d1b003-741a-444f-a80d-283e1c2e028b} executeQuery: Code: 481. DB::Exception: File is not inside /var/lib/clickhouse/user_files/. (PATH_ACCESS_DENIED) (version 25.3.6.10636.altinitytest (altinity build)) (from [::1]:34986) (comment: 02722_database_filesystem.sh) (query 1, line 1) (in query: SELECT COUNT(*) FROM test_fl5dx20u_test1.`../tmp_numbers_*.csv`;), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000a9b78ab 4. /build/src/Databases/DatabaseFilesystem.cpp:91: DB::DatabaseFilesystem::checkTableFilePath(String const&, std::shared_ptr, bool) const @ 0x0000000013d639dc 5. /build/src/Databases/DatabaseFilesystem.cpp:151: DB::DatabaseFilesystem::getTableImpl(String const&, std::shared_ptr, bool) const @ 0x0000000013d64038 6. /build/src/Databases/DatabaseFilesystem.cpp:180: DB::DatabaseFilesystem::tryGetTable(String const&, std::shared_ptr) const @ 0x0000000013d647a4 7. /build/src/Interpreters/DatabaseCatalog.cpp:451: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x00000000144f19c8 8. /build/src/Interpreters/DatabaseCatalog.cpp:984: DB::DatabaseCatalog::tryGetTable(DB::StorageID const&, std::shared_ptr) const @ 0x00000000144f6b77 9. /build/src/Analyzer/Resolve/IdentifierResolver.cpp:177: DB::IdentifierResolver::tryResolveTableIdentifierFromDatabaseCatalog(DB::Identifier const&, std::shared_ptr const&) @ 0x00000000142b9931 10. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:1550: DB::QueryAnalyzer::tryResolveIdentifier(DB::IdentifierLookup const&, DB::IdentifierResolveScope&, DB::IdentifierResolveContext) @ 0x00000000140299a0 11. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:4365: DB::QueryAnalyzer::initializeQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000014043a79 12. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5594: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000140135fb 13. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000140127f9 14. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000014011fce 15. /build/src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000001406ce8a 16. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000014973b42 17. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000001497268d 18. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000014974d24 19. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001492924b 20. /build/src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88641 21. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 22. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 23. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 24. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 25. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 26. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 27. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 28. ? @ 0x00007fbc6213eac3 29. ? @ 0x00007fbc621d0850 2025.07.28 11:49:52.425244 [ 5980 ] {} 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. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000a9b78ab 4. /build/src/Databases/DatabaseFilesystem.cpp:91: DB::DatabaseFilesystem::checkTableFilePath(String const&, std::shared_ptr, bool) const @ 0x0000000013d639dc 5. /build/src/Databases/DatabaseFilesystem.cpp:151: DB::DatabaseFilesystem::getTableImpl(String const&, std::shared_ptr, bool) const @ 0x0000000013d64038 6. /build/src/Databases/DatabaseFilesystem.cpp:180: DB::DatabaseFilesystem::tryGetTable(String const&, std::shared_ptr) const @ 0x0000000013d647a4 7. /build/src/Interpreters/DatabaseCatalog.cpp:451: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x00000000144f19c8 8. /build/src/Interpreters/DatabaseCatalog.cpp:984: DB::DatabaseCatalog::tryGetTable(DB::StorageID const&, std::shared_ptr) const @ 0x00000000144f6b77 9. /build/src/Analyzer/Resolve/IdentifierResolver.cpp:177: DB::IdentifierResolver::tryResolveTableIdentifierFromDatabaseCatalog(DB::Identifier const&, std::shared_ptr const&) @ 0x00000000142b9931 10. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:1550: DB::QueryAnalyzer::tryResolveIdentifier(DB::IdentifierLookup const&, DB::IdentifierResolveScope&, DB::IdentifierResolveContext) @ 0x00000000140299a0 11. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:4365: DB::QueryAnalyzer::initializeQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000014043a79 12. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5594: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000140135fb 13. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000140127f9 14. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000014011fce 15. /build/src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000001406ce8a 16. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000014973b42 17. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000001497268d 18. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000014974d24 19. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001492924b 20. /build/src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88641 21. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 22. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 23. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 24. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 25. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 26. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 27. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 28. ? @ 0x00007fbc6213eac3 29. ? @ 0x00007fbc621d0850 2025.07.28 11:49:52.748850 [ 4900 ] {d5c5d7ed-88a5-44d9-a625-c5056361137f} executeQuery: Code: 481. DB::Exception: File is not inside /var/lib/clickhouse/user_files/. (PATH_ACCESS_DENIED) (version 25.3.6.10636.altinitytest (altinity build)) (from [::1]:35010) (comment: 02722_database_filesystem.sh) (query 1, line 1) (in query: SELECT COUNT(*) FROM test_fl5dx20u_test1.`../*.csv`;), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000a9b78ab 4. /build/src/Databases/DatabaseFilesystem.cpp:91: DB::DatabaseFilesystem::checkTableFilePath(String const&, std::shared_ptr, bool) const @ 0x0000000013d639dc 5. /build/src/Databases/DatabaseFilesystem.cpp:151: DB::DatabaseFilesystem::getTableImpl(String const&, std::shared_ptr, bool) const @ 0x0000000013d64038 6. /build/src/Databases/DatabaseFilesystem.cpp:180: DB::DatabaseFilesystem::tryGetTable(String const&, std::shared_ptr) const @ 0x0000000013d647a4 7. /build/src/Interpreters/DatabaseCatalog.cpp:451: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x00000000144f19c8 8. /build/src/Interpreters/DatabaseCatalog.cpp:984: DB::DatabaseCatalog::tryGetTable(DB::StorageID const&, std::shared_ptr) const @ 0x00000000144f6b77 9. /build/src/Analyzer/Resolve/IdentifierResolver.cpp:177: DB::IdentifierResolver::tryResolveTableIdentifierFromDatabaseCatalog(DB::Identifier const&, std::shared_ptr const&) @ 0x00000000142b9931 10. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:1550: DB::QueryAnalyzer::tryResolveIdentifier(DB::IdentifierLookup const&, DB::IdentifierResolveScope&, DB::IdentifierResolveContext) @ 0x00000000140299a0 11. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:4365: DB::QueryAnalyzer::initializeQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000014043a79 12. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5594: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000140135fb 13. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000140127f9 14. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000014011fce 15. /build/src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000001406ce8a 16. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000014973b42 17. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000001497268d 18. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000014974d24 19. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001492924b 20. /build/src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88641 21. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 22. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 23. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 24. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 25. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 26. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 27. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 28. ? @ 0x00007fbc6213eac3 29. ? @ 0x00007fbc621d0850 2025.07.28 11:49:52.786318 [ 4900 ] {} 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. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000a9b78ab 4. /build/src/Databases/DatabaseFilesystem.cpp:91: DB::DatabaseFilesystem::checkTableFilePath(String const&, std::shared_ptr, bool) const @ 0x0000000013d639dc 5. /build/src/Databases/DatabaseFilesystem.cpp:151: DB::DatabaseFilesystem::getTableImpl(String const&, std::shared_ptr, bool) const @ 0x0000000013d64038 6. /build/src/Databases/DatabaseFilesystem.cpp:180: DB::DatabaseFilesystem::tryGetTable(String const&, std::shared_ptr) const @ 0x0000000013d647a4 7. /build/src/Interpreters/DatabaseCatalog.cpp:451: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x00000000144f19c8 8. /build/src/Interpreters/DatabaseCatalog.cpp:984: DB::DatabaseCatalog::tryGetTable(DB::StorageID const&, std::shared_ptr) const @ 0x00000000144f6b77 9. /build/src/Analyzer/Resolve/IdentifierResolver.cpp:177: DB::IdentifierResolver::tryResolveTableIdentifierFromDatabaseCatalog(DB::Identifier const&, std::shared_ptr const&) @ 0x00000000142b9931 10. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:1550: DB::QueryAnalyzer::tryResolveIdentifier(DB::IdentifierLookup const&, DB::IdentifierResolveScope&, DB::IdentifierResolveContext) @ 0x00000000140299a0 11. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:4365: DB::QueryAnalyzer::initializeQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000014043a79 12. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5594: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000140135fb 13. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000140127f9 14. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000014011fce 15. /build/src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000001406ce8a 16. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000014973b42 17. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000001497268d 18. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000014974d24 19. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001492924b 20. /build/src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88641 21. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 22. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 23. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 24. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 25. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 26. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 27. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 28. ? @ 0x00007fbc6213eac3 29. ? @ 0x00007fbc621d0850 2025.07.28 11:49:53.084064 [ 4900 ] {02c74e19-05ee-4e59-b1bd-90610b23057b} executeQuery: Code: 481. DB::Exception: File is not inside /var/lib/clickhouse/user_files/. (PATH_ACCESS_DENIED) (version 25.3.6.10636.altinitytest (altinity build)) (from [::1]:35062) (comment: 02722_database_filesystem.sh) (query 2, line 3) (in query: SELECT COUNT(*) FROM "../02722_database_filesystem_test_fl5dx20u_E9nv/tmp.csv";), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000a9b78ab 4. /build/src/Databases/DatabaseFilesystem.cpp:91: DB::DatabaseFilesystem::checkTableFilePath(String const&, std::shared_ptr, bool) const @ 0x0000000013d639dc 5. /build/src/Databases/DatabaseFilesystem.cpp:151: DB::DatabaseFilesystem::getTableImpl(String const&, std::shared_ptr, bool) const @ 0x0000000013d64038 6. /build/src/Databases/DatabaseFilesystem.cpp:180: DB::DatabaseFilesystem::tryGetTable(String const&, std::shared_ptr) const @ 0x0000000013d647a4 7. /build/src/Interpreters/DatabaseCatalog.cpp:451: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x00000000144f19c8 8. /build/src/Interpreters/DatabaseCatalog.cpp:984: DB::DatabaseCatalog::tryGetTable(DB::StorageID const&, std::shared_ptr) const @ 0x00000000144f6b77 9. /build/src/Analyzer/Resolve/IdentifierResolver.cpp:177: DB::IdentifierResolver::tryResolveTableIdentifierFromDatabaseCatalog(DB::Identifier const&, std::shared_ptr const&) @ 0x00000000142b9931 10. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:1550: DB::QueryAnalyzer::tryResolveIdentifier(DB::IdentifierLookup const&, DB::IdentifierResolveScope&, DB::IdentifierResolveContext) @ 0x00000000140299a0 11. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:4365: DB::QueryAnalyzer::initializeQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000014043a79 12. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5594: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000140135fb 13. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000140127f9 14. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000014011fce 15. /build/src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000001406ce8a 16. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000014973b42 17. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000001497268d 18. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000014974d24 19. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001492924b 20. /build/src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88641 21. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 22. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 23. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 24. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 25. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 26. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 27. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 28. ? @ 0x00007fbc6213eac3 29. ? @ 0x00007fbc621d0850 2025.07.28 11:49:53.107913 [ 4900 ] {} 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. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000a9b78ab 4. /build/src/Databases/DatabaseFilesystem.cpp:91: DB::DatabaseFilesystem::checkTableFilePath(String const&, std::shared_ptr, bool) const @ 0x0000000013d639dc 5. /build/src/Databases/DatabaseFilesystem.cpp:151: DB::DatabaseFilesystem::getTableImpl(String const&, std::shared_ptr, bool) const @ 0x0000000013d64038 6. /build/src/Databases/DatabaseFilesystem.cpp:180: DB::DatabaseFilesystem::tryGetTable(String const&, std::shared_ptr) const @ 0x0000000013d647a4 7. /build/src/Interpreters/DatabaseCatalog.cpp:451: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x00000000144f19c8 8. /build/src/Interpreters/DatabaseCatalog.cpp:984: DB::DatabaseCatalog::tryGetTable(DB::StorageID const&, std::shared_ptr) const @ 0x00000000144f6b77 9. /build/src/Analyzer/Resolve/IdentifierResolver.cpp:177: DB::IdentifierResolver::tryResolveTableIdentifierFromDatabaseCatalog(DB::Identifier const&, std::shared_ptr const&) @ 0x00000000142b9931 10. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:1550: DB::QueryAnalyzer::tryResolveIdentifier(DB::IdentifierLookup const&, DB::IdentifierResolveScope&, DB::IdentifierResolveContext) @ 0x00000000140299a0 11. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:4365: DB::QueryAnalyzer::initializeQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000014043a79 12. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5594: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000140135fb 13. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000140127f9 14. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000014011fce 15. /build/src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000001406ce8a 16. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000014973b42 17. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000001497268d 18. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000014974d24 19. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001492924b 20. /build/src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88641 21. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 22. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 23. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 24. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 25. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 26. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 27. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 28. ? @ 0x00007fbc6213eac3 29. ? @ 0x00007fbc621d0850 2025.07.28 11:49:53.320638 [ 5747 ] {2dee6334-bbf4-485f-9212-36c1e00b1b09} executeQuery: Code: 481. DB::Exception: File is not inside /var/lib/clickhouse/user_files/. (PATH_ACCESS_DENIED) (version 25.3.6.10636.altinitytest (altinity build)) (from [::1]:35090) (comment: 02722_database_filesystem.sh) (query 1, line 1) (in query: SELECT COUNT(*) FROM test_fl5dx20u_test1.`../../../../../../tmp.csv`;), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000a9b78ab 4. /build/src/Databases/DatabaseFilesystem.cpp:91: DB::DatabaseFilesystem::checkTableFilePath(String const&, std::shared_ptr, bool) const @ 0x0000000013d639dc 5. /build/src/Databases/DatabaseFilesystem.cpp:151: DB::DatabaseFilesystem::getTableImpl(String const&, std::shared_ptr, bool) const @ 0x0000000013d64038 6. /build/src/Databases/DatabaseFilesystem.cpp:180: DB::DatabaseFilesystem::tryGetTable(String const&, std::shared_ptr) const @ 0x0000000013d647a4 7. /build/src/Interpreters/DatabaseCatalog.cpp:451: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x00000000144f19c8 8. /build/src/Interpreters/DatabaseCatalog.cpp:984: DB::DatabaseCatalog::tryGetTable(DB::StorageID const&, std::shared_ptr) const @ 0x00000000144f6b77 9. /build/src/Analyzer/Resolve/IdentifierResolver.cpp:177: DB::IdentifierResolver::tryResolveTableIdentifierFromDatabaseCatalog(DB::Identifier const&, std::shared_ptr const&) @ 0x00000000142b9931 10. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:1550: DB::QueryAnalyzer::tryResolveIdentifier(DB::IdentifierLookup const&, DB::IdentifierResolveScope&, DB::IdentifierResolveContext) @ 0x00000000140299a0 11. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:4365: DB::QueryAnalyzer::initializeQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000014043a79 12. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5594: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000140135fb 13. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000140127f9 14. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000014011fce 15. /build/src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000001406ce8a 16. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000014973b42 17. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000001497268d 18. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000014974d24 19. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001492924b 20. /build/src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88641 21. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 22. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 23. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 24. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 25. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 26. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 27. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 28. ? @ 0x00007fbc6213eac3 29. ? @ 0x00007fbc621d0850 2025.07.28 11:49:53.335878 [ 5747 ] {} 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. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000a9b78ab 4. /build/src/Databases/DatabaseFilesystem.cpp:91: DB::DatabaseFilesystem::checkTableFilePath(String const&, std::shared_ptr, bool) const @ 0x0000000013d639dc 5. /build/src/Databases/DatabaseFilesystem.cpp:151: DB::DatabaseFilesystem::getTableImpl(String const&, std::shared_ptr, bool) const @ 0x0000000013d64038 6. /build/src/Databases/DatabaseFilesystem.cpp:180: DB::DatabaseFilesystem::tryGetTable(String const&, std::shared_ptr) const @ 0x0000000013d647a4 7. /build/src/Interpreters/DatabaseCatalog.cpp:451: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x00000000144f19c8 8. /build/src/Interpreters/DatabaseCatalog.cpp:984: DB::DatabaseCatalog::tryGetTable(DB::StorageID const&, std::shared_ptr) const @ 0x00000000144f6b77 9. /build/src/Analyzer/Resolve/IdentifierResolver.cpp:177: DB::IdentifierResolver::tryResolveTableIdentifierFromDatabaseCatalog(DB::Identifier const&, std::shared_ptr const&) @ 0x00000000142b9931 10. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:1550: DB::QueryAnalyzer::tryResolveIdentifier(DB::IdentifierLookup const&, DB::IdentifierResolveScope&, DB::IdentifierResolveContext) @ 0x00000000140299a0 11. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:4365: DB::QueryAnalyzer::initializeQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000014043a79 12. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5594: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000140135fb 13. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000140127f9 14. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000014011fce 15. /build/src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000001406ce8a 16. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000014973b42 17. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000001497268d 18. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000014974d24 19. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001492924b 20. /build/src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88641 21. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 22. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 23. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 24. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 25. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 26. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 27. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 28. ? @ 0x00007fbc6213eac3 29. ? @ 0x00007fbc621d0850 2025.07.28 11:49:53.756301 [ 6138 ] {74b59fea-abb1-492c-a407-22d3a42997c1} executeQuery: Code: 36. DB::Exception: Path must be inside user-files path: /var/lib/clickhouse/user_files. (BAD_ARGUMENTS) (version 25.3.6.10636.altinitytest (altinity build)) (from [::1]:35124) (comment: 02722_database_filesystem.sh) (query 2, line 3) (in query: CREATE DATABASE test_fl5dx20u_test2 ENGINE = Filesystem('/tmp');), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x000000000a06b56b 4. /build/src/Databases/DatabaseFilesystem.cpp:56: DB::DatabaseFilesystem::DatabaseFilesystem(String const&, String const&, std::shared_ptr) @ 0x0000000013d62f9e 5. /build/contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: std::shared_ptr std::allocate_shared[abi:se190107], String const&, String&, std::shared_ptr&, 0>(std::allocator const&, String const&, String&, std::shared_ptr&) @ 0x0000000013d66298 6. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:851: std::shared_ptr std::__function::__policy_invoker (DB::DatabaseFactory::Arguments const&)>::__call_impl[abi:se190107] (DB::DatabaseFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::DatabaseFactory::Arguments const&) @ 0x0000000013d65398 7. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000013d60f76 8. /build/src/Databases/DatabaseFactory.cpp:111: DB::DatabaseFactory::get(DB::ASTCreateQuery const&, String const&, std::shared_ptr) @ 0x0000000013d609c1 9. /build/src/Interpreters/InterpreterCreateQuery.cpp:341: DB::InterpreterCreateQuery::createDatabase(DB::ASTCreateQuery&) @ 0x00000000148e882e 10. /build/src/Interpreters/InterpreterCreateQuery.cpp:2351: DB::InterpreterCreateQuery::execute() @ 0x0000000014905a3a 11. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88dc9 12. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 13. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 14. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 15. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 16. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 17. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 18. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 19. ? @ 0x00007fbc6213eac3 20. ? @ 0x00007fbc621d0850 2025.07.28 11:49:53.785376 [ 6138 ] {} 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. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x000000000a06b56b 4. /build/src/Databases/DatabaseFilesystem.cpp:56: DB::DatabaseFilesystem::DatabaseFilesystem(String const&, String const&, std::shared_ptr) @ 0x0000000013d62f9e 5. /build/contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: std::shared_ptr std::allocate_shared[abi:se190107], String const&, String&, std::shared_ptr&, 0>(std::allocator const&, String const&, String&, std::shared_ptr&) @ 0x0000000013d66298 6. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:851: std::shared_ptr std::__function::__policy_invoker (DB::DatabaseFactory::Arguments const&)>::__call_impl[abi:se190107] (DB::DatabaseFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::DatabaseFactory::Arguments const&) @ 0x0000000013d65398 7. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000013d60f76 8. /build/src/Databases/DatabaseFactory.cpp:111: DB::DatabaseFactory::get(DB::ASTCreateQuery const&, String const&, std::shared_ptr) @ 0x0000000013d609c1 9. /build/src/Interpreters/InterpreterCreateQuery.cpp:341: DB::InterpreterCreateQuery::createDatabase(DB::ASTCreateQuery&) @ 0x00000000148e882e 10. /build/src/Interpreters/InterpreterCreateQuery.cpp:2351: DB::InterpreterCreateQuery::execute() @ 0x0000000014905a3a 11. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88dc9 12. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 13. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 14. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 15. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 16. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 17. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 18. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 19. ? @ 0x00007fbc6213eac3 20. ? @ 0x00007fbc621d0850 2025.07.28 11:49:54.305528 [ 4446 ] {test_00601_test_3upfag71} executeQuery: Code: 394. DB::Exception: Query was cancelled. (QUERY_WAS_CANCELLED) (version 25.3.6.10636.altinitytest (altinity build)) (from [::ffff:127.0.0.1]:39844) (comment: 00601_kill_running_query.sh) (in query: SELECT sum(ignore(*)) FROM (SELECT number % 1000 AS k, groupArray(number) FROM numbers(50000000) GROUP BY k) SETTINGS max_rows_to_read = 0), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000000a074fcb 4. /build/src/Interpreters/ProcessList.cpp:567: DB::QueryStatus::throwQueryWasCancelled() const @ 0x0000000014a4bc85 5. /build/src/Interpreters/ProcessList.cpp:520: DB::QueryStatus::throwProperExceptionIfNeeded(unsigned long const&, unsigned long const&) @ 0x0000000014a4bbd9 6. /build/src/Interpreters/ProcessList.cpp:557: DB::QueryStatus::checkTimeLimit() @ 0x0000000014a4c2cd 7. /build/src/Processors/Executors/PipelineExecutor.cpp:206: DB::PipelineExecutor::finalizeExecution() @ 0x00000000169b13ba 8. /build/src/Processors/Executors/PipelineExecutor.cpp:153: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x00000000169b0584 9. /build/src/Processors/Executors/CompletedPipelineExecutor.cpp:105: DB::CompletedPipelineExecutor::execute() @ 0x00000000169af3c4 10. /build/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&)>) @ 0x0000000014c8d123 11. /build/src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000001686da12 12. /build/src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x0000000016870807 13. /build/src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x0000000016907e99 14. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 15. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 16. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 17. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 18. ? @ 0x00007fbc6213eac3 19. ? @ 0x00007fbc621d0850 2025.07.28 11:49:54.315845 [ 5747 ] {7f127289-eb9d-43d0-bf54-e2092cc3bf71} executeQuery: Code: 36. DB::Exception: Path does not exist: /var/lib/clickhouse/user_files/relative_unknown_dir. (BAD_ARGUMENTS) (version 25.3.6.10636.altinitytest (altinity build)) (from [::1]:35168) (comment: 02722_database_filesystem.sh) (query 2, line 3) (in query: CREATE DATABASE test_fl5dx20u_test2 ENGINE = Filesystem('relative_unknown_dir');), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x000000000a080b2b 4. /build/src/Databases/DatabaseFilesystem.cpp:61: DB::DatabaseFilesystem::DatabaseFilesystem(String const&, String const&, std::shared_ptr) @ 0x0000000013d62f40 5. /build/contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: std::shared_ptr std::allocate_shared[abi:se190107], String const&, String&, std::shared_ptr&, 0>(std::allocator const&, String const&, String&, std::shared_ptr&) @ 0x0000000013d66298 6. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:851: std::shared_ptr std::__function::__policy_invoker (DB::DatabaseFactory::Arguments const&)>::__call_impl[abi:se190107] (DB::DatabaseFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::DatabaseFactory::Arguments const&) @ 0x0000000013d65398 7. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000013d60f76 8. /build/src/Databases/DatabaseFactory.cpp:111: DB::DatabaseFactory::get(DB::ASTCreateQuery const&, String const&, std::shared_ptr) @ 0x0000000013d609c1 9. /build/src/Interpreters/InterpreterCreateQuery.cpp:341: DB::InterpreterCreateQuery::createDatabase(DB::ASTCreateQuery&) @ 0x00000000148e882e 10. /build/src/Interpreters/InterpreterCreateQuery.cpp:2351: DB::InterpreterCreateQuery::execute() @ 0x0000000014905a3a 11. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88dc9 12. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 13. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 14. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 15. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 16. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 17. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 18. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 19. ? @ 0x00007fbc6213eac3 20. ? @ 0x00007fbc621d0850 2025.07.28 11:49:54.330632 [ 5747 ] {} 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. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x000000000a080b2b 4. /build/src/Databases/DatabaseFilesystem.cpp:61: DB::DatabaseFilesystem::DatabaseFilesystem(String const&, String const&, std::shared_ptr) @ 0x0000000013d62f40 5. /build/contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: std::shared_ptr std::allocate_shared[abi:se190107], String const&, String&, std::shared_ptr&, 0>(std::allocator const&, String const&, String&, std::shared_ptr&) @ 0x0000000013d66298 6. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:851: std::shared_ptr std::__function::__policy_invoker (DB::DatabaseFactory::Arguments const&)>::__call_impl[abi:se190107] (DB::DatabaseFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::DatabaseFactory::Arguments const&) @ 0x0000000013d65398 7. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000013d60f76 8. /build/src/Databases/DatabaseFactory.cpp:111: DB::DatabaseFactory::get(DB::ASTCreateQuery const&, String const&, std::shared_ptr) @ 0x0000000013d609c1 9. /build/src/Interpreters/InterpreterCreateQuery.cpp:341: DB::InterpreterCreateQuery::createDatabase(DB::ASTCreateQuery&) @ 0x00000000148e882e 10. /build/src/Interpreters/InterpreterCreateQuery.cpp:2351: DB::InterpreterCreateQuery::execute() @ 0x0000000014905a3a 11. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88dc9 12. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 13. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 14. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 15. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 16. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 17. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 18. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 19. ? @ 0x00007fbc6213eac3 20. ? @ 0x00007fbc621d0850 2025.07.28 11:49:54.583034 [ 4446 ] {test_00601_test_3upfag71} DynamicQueryHandler: Code: 394. DB::Exception: Query was cancelled. (QUERY_WAS_CANCELLED), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000000a074fcb 4. /build/src/Interpreters/ProcessList.cpp:567: DB::QueryStatus::throwQueryWasCancelled() const @ 0x0000000014a4bc85 5. /build/src/Interpreters/ProcessList.cpp:520: DB::QueryStatus::throwProperExceptionIfNeeded(unsigned long const&, unsigned long const&) @ 0x0000000014a4bbd9 6. /build/src/Interpreters/ProcessList.cpp:557: DB::QueryStatus::checkTimeLimit() @ 0x0000000014a4c2cd 7. /build/src/Processors/Executors/PipelineExecutor.cpp:206: DB::PipelineExecutor::finalizeExecution() @ 0x00000000169b13ba 8. /build/src/Processors/Executors/PipelineExecutor.cpp:153: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x00000000169b0584 9. /build/src/Processors/Executors/CompletedPipelineExecutor.cpp:105: DB::CompletedPipelineExecutor::execute() @ 0x00000000169af3c4 10. /build/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&)>) @ 0x0000000014c8d123 11. /build/src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000001686da12 12. /build/src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x0000000016870807 13. /build/src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x0000000016907e99 14. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 15. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 16. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 17. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 18. ? @ 0x00007fbc6213eac3 19. ? @ 0x00007fbc621d0850 (version 25.3.6.10636.altinitytest (altinity build)) 2025.07.28 11:49:54.637473 [ 4900 ] {5f099c86-0585-43da-8e2e-50634fa4fe7e} executeQuery: Code: 60. DB::Exception: Unknown table expression identifier 'test_fl5dx20u_test1.tmp2.csv' in scope SELECT COUNT(*) FROM test_fl5dx20u_test1.`tmp2.csv`. (UNKNOWN_TABLE) (version 25.3.6.10636.altinitytest (altinity build)) (from [::1]:35206) (comment: 02722_database_filesystem.sh) (query 1, line 1) (in query: SELECT COUNT(*) FROM test_fl5dx20u_test1.`tmp2.csv`;), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x000000000a6a1e2b 4. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:4372: DB::QueryAnalyzer::initializeQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000001404440b 5. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5594: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000140135fb 6. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000140127f9 7. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000014011fce 8. /build/src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000001406ce8a 9. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000014973b42 10. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000001497268d 11. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000014974d24 12. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001492924b 13. /build/src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88641 14. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 15. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 16. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 17. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 18. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 19. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 20. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 21. ? @ 0x00007fbc6213eac3 22. ? @ 0x00007fbc621d0850 2025.07.28 11:49:54.659969 [ 4900 ] {} TCPHandler: Code: 60. DB::Exception: Unknown table expression identifier 'test_fl5dx20u_test1.tmp2.csv' in scope SELECT COUNT(*) FROM test_fl5dx20u_test1.`tmp2.csv`. (UNKNOWN_TABLE), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x000000000a6a1e2b 4. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:4372: DB::QueryAnalyzer::initializeQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000001404440b 5. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5594: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000140135fb 6. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000140127f9 7. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000014011fce 8. /build/src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000001406ce8a 9. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000014973b42 10. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000001497268d 11. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000014974d24 12. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001492924b 13. /build/src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88641 14. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 15. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 16. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 17. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 18. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 19. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 20. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 21. ? @ 0x00007fbc6213eac3 22. ? @ 0x00007fbc621d0850 2025.07.28 11:49:55.420305 [ 4526 ] {441d63fe-da3b-4fbc-aad0-a22b646eadb2} executeQuery: Code: 524. DB::Exception: ALTER of partition key column x from type Enum8('hello' = 1, 'world' = 2, 'goodbye' = 3) to type Enum8('hello' = 1, 'world' = 2) is not safe because it can change the representation of partition key. (ALTER_OF_COLUMN_IS_FORBIDDEN) (version 25.3.6.10636.altinitytest (altinity build)) (from [::1]:34912) (comment: 01344_alter_enum_partition_key.sql) (query 11, line 14) (in query: ALTER TABLE test MODIFY COLUMN x Enum('hello' = 1, 'world' = 2);), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&) @ 0x000000000a10182b 4. /build/src/Storages/MergeTree/MergeTreeData.cpp:3821: DB::MergeTreeData::checkAlterIsPossible(DB::AlterCommands const&, std::shared_ptr) const @ 0x0000000016338c98 5. /build/src/Interpreters/InterpreterAlterQuery.cpp:215: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x00000000148deab3 6. /build/src/Interpreters/InterpreterAlterQuery.cpp:77: DB::InterpreterAlterQuery::execute() @ 0x00000000148dcb0d 7. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88dc9 8. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 9. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 10. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 11. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 12. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 13. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 14. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 15. ? @ 0x00007fbc6213eac3 16. ? @ 0x00007fbc621d0850 2025.07.28 11:49:55.425539 [ 4526 ] {} TCPHandler: Code: 524. DB::Exception: ALTER of partition key column x from type Enum8('hello' = 1, 'world' = 2, 'goodbye' = 3) to type Enum8('hello' = 1, 'world' = 2) is not safe because it can change the representation of partition key. (ALTER_OF_COLUMN_IS_FORBIDDEN), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&) @ 0x000000000a10182b 4. /build/src/Storages/MergeTree/MergeTreeData.cpp:3821: DB::MergeTreeData::checkAlterIsPossible(DB::AlterCommands const&, std::shared_ptr) const @ 0x0000000016338c98 5. /build/src/Interpreters/InterpreterAlterQuery.cpp:215: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x00000000148deab3 6. /build/src/Interpreters/InterpreterAlterQuery.cpp:77: DB::InterpreterAlterQuery::execute() @ 0x00000000148dcb0d 7. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88dc9 8. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 9. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 10. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 11. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 12. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 13. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 14. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 15. ? @ 0x00007fbc6213eac3 16. ? @ 0x00007fbc621d0850 2025.07.28 11:49:55.800441 [ 4526 ] {cb47adeb-d241-4539-bf1e-09ea328f3715} executeQuery: Code: 524. DB::Exception: ALTER of partition key column x from type Enum8('hello' = 1, 'world' = 2, 'test' = 3) to type Enum8('hello' = 1, 'world' = 2, 'goodbye' = 4) is not safe because it can change the representation of partition key. (ALTER_OF_COLUMN_IS_FORBIDDEN) (version 25.3.6.10636.altinitytest (altinity build)) (from [::1]:34912) (comment: 01344_alter_enum_partition_key.sql) (query 13, line 16) (in query: ALTER TABLE test MODIFY COLUMN x Enum('hello' = 1, 'world' = 2, 'goodbye' = 4);), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&) @ 0x000000000a10182b 4. /build/src/Storages/MergeTree/MergeTreeData.cpp:3821: DB::MergeTreeData::checkAlterIsPossible(DB::AlterCommands const&, std::shared_ptr) const @ 0x0000000016338c98 5. /build/src/Interpreters/InterpreterAlterQuery.cpp:215: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x00000000148deab3 6. /build/src/Interpreters/InterpreterAlterQuery.cpp:77: DB::InterpreterAlterQuery::execute() @ 0x00000000148dcb0d 7. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88dc9 8. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 9. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 10. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 11. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 12. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 13. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 14. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 15. ? @ 0x00007fbc6213eac3 16. ? @ 0x00007fbc621d0850 2025.07.28 11:49:55.805093 [ 4526 ] {} TCPHandler: Code: 524. DB::Exception: ALTER of partition key column x from type Enum8('hello' = 1, 'world' = 2, 'test' = 3) to type Enum8('hello' = 1, 'world' = 2, 'goodbye' = 4) is not safe because it can change the representation of partition key. (ALTER_OF_COLUMN_IS_FORBIDDEN), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&) @ 0x000000000a10182b 4. /build/src/Storages/MergeTree/MergeTreeData.cpp:3821: DB::MergeTreeData::checkAlterIsPossible(DB::AlterCommands const&, std::shared_ptr) const @ 0x0000000016338c98 5. /build/src/Interpreters/InterpreterAlterQuery.cpp:215: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x00000000148deab3 6. /build/src/Interpreters/InterpreterAlterQuery.cpp:77: DB::InterpreterAlterQuery::execute() @ 0x00000000148dcb0d 7. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88dc9 8. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 9. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 10. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 11. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 12. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 13. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 14. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 15. ? @ 0x00007fbc6213eac3 16. ? @ 0x00007fbc621d0850 2025.07.28 11:49:56.877437 [ 5747 ] {} DynamicQueryHandler: Code: 48. DB::Exception: Unsupported compression method. (NOT_IMPLEMENTED), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000000a074fcb 4. /build/src/IO/CompressionMethod.cpp:197: std::unique_ptr> DB::createWriteCompressedWrapper(DB::WriteBuffer*&, DB::CompressionMethod, int, int, unsigned long, char*, unsigned long, bool) @ 0x000000000fe4c1d1 5. /build/src/IO/CompressionMethod.cpp:231: DB::wrapWriteBufferWithCompressionMethod(DB::WriteBuffer*, DB::CompressionMethod, int, int, unsigned long, char*, unsigned long, bool) @ 0x000000000fe4bc1f 6. /build/src/Server/HTTPHandler.cpp:314: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000001686ba46 7. /build/src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x0000000016870807 8. /build/src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x0000000016907e99 9. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 10. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 11. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 12. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 13. ? @ 0x00007fbc6213eac3 14. ? @ 0x00007fbc621d0850 (version 25.3.6.10636.altinitytest (altinity build)) 2025.07.28 11:49:57.120326 [ 4900 ] {36727f0f-ce0f-4969-80e6-0f343e22374d} executeQuery: Code: 241. DB::Exception: Query memory tracker: fault injected. Would use 3.23 MiB (attempt to allocate chunk of 1.08 MiB), maximum: 9.31 GiB. (MEMORY_LIMIT_EXCEEDED) (version 25.3.6.10636.altinitytest (altinity build)) (from [::1]:35306) (comment: 02703_row_policy_for_database.sh) (query 4, line 7) (in query: INSERT INTO 02703_rqtable_default VALUES ), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.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&&) @ 0x000000000fc1a9d9 4. /build/src/Common/MemoryTracker.cpp:298: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000000fc19854 5. /build/src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000000fc19293 6. /build/src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000000fb80c54 7. /build/src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000000fb7f3c4 8. /build/src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000000fc687b2 9. /build/src/IO/BufferWithOwnMemory.h:47: DB::CompressedWriteBuffer::CompressedWriteBuffer(DB::WriteBuffer&, std::shared_ptr, unsigned long, bool, unsigned long) @ 0x0000000017939c8a 10. /build/src/Storages/MergeTree/MergeTreeDataPartWriterCompact.h:87: std::shared_ptr std::allocate_shared[abi:se190107], DB::HashingWriteBuffer&, std::shared_ptr&, 0>(std::allocator const&, DB::HashingWriteBuffer&, std::shared_ptr&) @ 0x00000000163d4fc6 11. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:851: void std::__function::__policy_invoker::__call_impl[abi:se190107]::immutable_ptr const&, std::shared_ptr const&)::$_0, void (DB::ISerialization::SubstreamPath const&)>>(std::__function::__policy_storage const*, DB::ISerialization::SubstreamPath const&) @ 0x00000000163d31ee 12. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000013c7aa09 13. /build/src/DataTypes/Serializations/ISerialization.cpp:104: DB::ISerialization::enumerateStreams(std::function const&, std::shared_ptr const&, COW::immutable_ptr const&) const @ 0x0000000013c7acfd 14. /build/src/Storages/MergeTree/MergeTreeDataPartWriterCompact.cpp:100: DB::MergeTreeDataPartWriterCompact::addStreams(DB::NameAndTypePair const&, COW::immutable_ptr const&, std::shared_ptr const&) @ 0x00000000163d0db5 15. /build/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) @ 0x00000000163d0a0b 16. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: DB::createMergeTreeDataPartCompactWriter(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x00000000163c2af7 17. /build/src/Storages/MergeTree/IMergeTreeDataPartWriter.cpp:193: DB::createMergeTreeDataPartWriter(DB::MergeTreeDataPartType, String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x00000000162f402d 18. /build/src/Storages/MergeTree/MergedBlockOutputStream.cpp:62: DB::MergedBlockOutputStream::MergedBlockOutputStream(std::shared_ptr const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, std::shared_ptr, std::shared_ptr, DB::TransactionID, unsigned long, bool, bool, DB::WriteSettings const&) @ 0x000000001651a563 19. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: DB::MergeTreeDataWriter::writeTempPartImpl(DB::BlockWithPartition&, std::shared_ptr const&, std::shared_ptr, long, bool) @ 0x000000001640d53c 20. /build/src/Storages/MergeTree/MergeTreeDataWriter.cpp:485: DB::MergeTreeDataWriter::writeTempPart(DB::BlockWithPartition&, std::shared_ptr const&, std::shared_ptr) @ 0x000000001640a7df 21. /build/src/Storages/MergeTree/MergeTreeSink.cpp:127: DB::MergeTreeSink::consume(DB::Chunk&) @ 0x000000001666cf54 22. /build/src/Processors/Sinks/SinkToStorage.cpp:10: DB::SinkToStorage::onConsume(DB::Chunk) @ 0x0000000016cee093 23. /build/src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: void std::__function::__policy_invoker::__call_impl[abi:se190107]>(std::__function::__policy_storage const*) @ 0x0000000016c0ad89 24. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000016c0abf5 25. /build/src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: DB::ExceptionKeepingTransform::work() @ 0x0000000016c0a6fe 26. /build/src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x00000000169bd00f 27. /build/src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x00000000169b2105 28. /build/src/Processors/Executors/PipelineExecutor.cpp:170: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x00000000169b16a7 29. /build/src/Processors/Executors/PushingPipelineExecutor.cpp:131: DB::PushingPipelineExecutor::finish() @ 0x00000000169c359f 30. /build/src/Server/TCPHandler.cpp:1128: DB::TCPHandler::processInsertQuery(DB::QueryState&) @ 0x00000000168f0d2c 31. /build/src/Server/TCPHandler.cpp:673: DB::TCPHandler::runImpl() @ 0x00000000168e68bc 2025.07.28 11:49:57.141139 [ 4900 ] {} TCPHandler: Code: 241. DB::Exception: Query memory tracker: fault injected. Would use 3.23 MiB (attempt to allocate chunk of 1.08 MiB), maximum: 9.31 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.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&&) @ 0x000000000fc1a9d9 4. /build/src/Common/MemoryTracker.cpp:298: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000000fc19854 5. /build/src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000000fc19293 6. /build/src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000000fb80c54 7. /build/src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000000fb7f3c4 8. /build/src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000000fc687b2 9. /build/src/IO/BufferWithOwnMemory.h:47: DB::CompressedWriteBuffer::CompressedWriteBuffer(DB::WriteBuffer&, std::shared_ptr, unsigned long, bool, unsigned long) @ 0x0000000017939c8a 10. /build/src/Storages/MergeTree/MergeTreeDataPartWriterCompact.h:87: std::shared_ptr std::allocate_shared[abi:se190107], DB::HashingWriteBuffer&, std::shared_ptr&, 0>(std::allocator const&, DB::HashingWriteBuffer&, std::shared_ptr&) @ 0x00000000163d4fc6 11. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:851: void std::__function::__policy_invoker::__call_impl[abi:se190107]::immutable_ptr const&, std::shared_ptr const&)::$_0, void (DB::ISerialization::SubstreamPath const&)>>(std::__function::__policy_storage const*, DB::ISerialization::SubstreamPath const&) @ 0x00000000163d31ee 12. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000013c7aa09 13. /build/src/DataTypes/Serializations/ISerialization.cpp:104: DB::ISerialization::enumerateStreams(std::function const&, std::shared_ptr const&, COW::immutable_ptr const&) const @ 0x0000000013c7acfd 14. /build/src/Storages/MergeTree/MergeTreeDataPartWriterCompact.cpp:100: DB::MergeTreeDataPartWriterCompact::addStreams(DB::NameAndTypePair const&, COW::immutable_ptr const&, std::shared_ptr const&) @ 0x00000000163d0db5 15. /build/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) @ 0x00000000163d0a0b 16. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: DB::createMergeTreeDataPartCompactWriter(String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x00000000163c2af7 17. /build/src/Storages/MergeTree/IMergeTreeDataPartWriter.cpp:193: DB::createMergeTreeDataPartWriter(DB::MergeTreeDataPartType, String const&, String const&, std::unordered_map, std::hash, std::equal_to, std::allocator>>> const&, std::shared_ptr, DB::MergeTreeIndexGranularityInfo const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, String const&, std::shared_ptr const&, DB::MergeTreeWriterSettings const&, std::shared_ptr) @ 0x00000000162f402d 18. /build/src/Storages/MergeTree/MergedBlockOutputStream.cpp:62: DB::MergedBlockOutputStream::MergedBlockOutputStream(std::shared_ptr const&, std::shared_ptr const&, DB::NamesAndTypesList const&, std::vector, std::allocator>> const&, std::vector, std::allocator>> const&, std::shared_ptr, std::shared_ptr, DB::TransactionID, unsigned long, bool, bool, DB::WriteSettings const&) @ 0x000000001651a563 19. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: DB::MergeTreeDataWriter::writeTempPartImpl(DB::BlockWithPartition&, std::shared_ptr const&, std::shared_ptr, long, bool) @ 0x000000001640d53c 20. /build/src/Storages/MergeTree/MergeTreeDataWriter.cpp:485: DB::MergeTreeDataWriter::writeTempPart(DB::BlockWithPartition&, std::shared_ptr const&, std::shared_ptr) @ 0x000000001640a7df 21. /build/src/Storages/MergeTree/MergeTreeSink.cpp:127: DB::MergeTreeSink::consume(DB::Chunk&) @ 0x000000001666cf54 22. /build/src/Processors/Sinks/SinkToStorage.cpp:10: DB::SinkToStorage::onConsume(DB::Chunk) @ 0x0000000016cee093 23. /build/src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: void std::__function::__policy_invoker::__call_impl[abi:se190107]>(std::__function::__policy_storage const*) @ 0x0000000016c0ad89 24. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000016c0abf5 25. /build/src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: DB::ExceptionKeepingTransform::work() @ 0x0000000016c0a6fe 26. /build/src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x00000000169bd00f 27. /build/src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x00000000169b2105 28. /build/src/Processors/Executors/PipelineExecutor.cpp:170: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x00000000169b16a7 29. /build/src/Processors/Executors/PushingPipelineExecutor.cpp:131: DB::PushingPipelineExecutor::finish() @ 0x00000000169c359f 30. /build/src/Server/TCPHandler.cpp:1128: DB::TCPHandler::processInsertQuery(DB::QueryState&) @ 0x00000000168f0d2c 31. /build/src/Server/TCPHandler.cpp:673: DB::TCPHandler::runImpl() @ 0x00000000168e68bc 2025.07.28 11:49:57.781603 [ 5747 ] {319e98c0-e3b7-4a7b-b650-635ec20c2a86} executeQuery: Code: 36. DB::Exception: 'lifetime' parameter is redundant for the dictionary' of layout 'direct': While processing PRIMARY KEY key SOURCE(CLICKHOUSE(TABLE 'dict_source')) LIFETIME(MIN 0 MAX 0) LAYOUT(DIRECT()). (BAD_ARGUMENTS) (version 25.3.6.10636.altinitytest (altinity build)) (from [::1]:35366) (comment: 02716_create_direct_dict_with_lifetime_throws.sql) (query 2, line 3) (in query: CREATE DICTIONARY dict(`key` UInt64,`value` String) PRIMARY KEY key SOURCE(CLICKHOUSE(table 'dict_source')) LAYOUT(DIRECT()) LIFETIME(0);), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x000000000a080b2b 4. /build/src/Dictionaries/getDictionaryConfigurationFromAST.cpp:598: DB::checkLifetime(DB::ASTCreateQuery const&) @ 0x0000000013d46467 5. /build/src/Dictionaries/getDictionaryConfigurationFromAST.cpp:610: DB::getDictionaryConfigurationFromAST(DB::ASTCreateQuery const&, std::shared_ptr, String const&) @ 0x0000000013d465b6 6. /build/src/Databases/DDLDependencyVisitor.cpp:128: DB::InDepthNodeVisitor const>::doVisit(std::shared_ptr const&) @ 0x0000000013d42246 7. /build/src/Interpreters/InDepthNodeVisitor.h:61: void DB::InDepthNodeVisitor const>::visitImplMain(std::shared_ptr const&) @ 0x0000000013d44280 8. /build/src/Interpreters/InDepthNodeVisitor.h:51: DB::getDependenciesFromCreateQuery(std::shared_ptr const&, DB::QualifiedTableName const&, std::shared_ptr const&, String const&, bool) @ 0x0000000013d413b2 9. /build/src/Interpreters/InterpreterCreateQuery.cpp:1491: DB::(anonymous namespace)::checkTableCanBeAddedWithNoCyclicDependencies(DB::ASTCreateQuery const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000014903d1a 10. /build/src/Interpreters/InterpreterCreateQuery.cpp:1917: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x0000000014900318 11. /build/src/Interpreters/InterpreterCreateQuery.cpp:1743: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000148f9aa9 12. /build/src/Interpreters/InterpreterCreateQuery.cpp:2352: DB::InterpreterCreateQuery::execute() @ 0x0000000014905a41 13. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88dc9 14. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 15. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 16. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 17. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 18. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 19. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 20. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 21. ? @ 0x00007fbc6213eac3 22. ? @ 0x00007fbc621d0850 2025.07.28 11:49:57.784671 [ 5747 ] {} TCPHandler: Code: 36. DB::Exception: 'lifetime' parameter is redundant for the dictionary' of layout 'direct': While processing PRIMARY KEY key SOURCE(CLICKHOUSE(TABLE 'dict_source')) LIFETIME(MIN 0 MAX 0) LAYOUT(DIRECT()). (BAD_ARGUMENTS), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x000000000a080b2b 4. /build/src/Dictionaries/getDictionaryConfigurationFromAST.cpp:598: DB::checkLifetime(DB::ASTCreateQuery const&) @ 0x0000000013d46467 5. /build/src/Dictionaries/getDictionaryConfigurationFromAST.cpp:610: DB::getDictionaryConfigurationFromAST(DB::ASTCreateQuery const&, std::shared_ptr, String const&) @ 0x0000000013d465b6 6. /build/src/Databases/DDLDependencyVisitor.cpp:128: DB::InDepthNodeVisitor const>::doVisit(std::shared_ptr const&) @ 0x0000000013d42246 7. /build/src/Interpreters/InDepthNodeVisitor.h:61: void DB::InDepthNodeVisitor const>::visitImplMain(std::shared_ptr const&) @ 0x0000000013d44280 8. /build/src/Interpreters/InDepthNodeVisitor.h:51: DB::getDependenciesFromCreateQuery(std::shared_ptr const&, DB::QualifiedTableName const&, std::shared_ptr const&, String const&, bool) @ 0x0000000013d413b2 9. /build/src/Interpreters/InterpreterCreateQuery.cpp:1491: DB::(anonymous namespace)::checkTableCanBeAddedWithNoCyclicDependencies(DB::ASTCreateQuery const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000014903d1a 10. /build/src/Interpreters/InterpreterCreateQuery.cpp:1917: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x0000000014900318 11. /build/src/Interpreters/InterpreterCreateQuery.cpp:1743: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000148f9aa9 12. /build/src/Interpreters/InterpreterCreateQuery.cpp:2352: DB::InterpreterCreateQuery::execute() @ 0x0000000014905a41 13. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88dc9 14. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 15. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 16. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 17. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 18. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 19. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 20. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 21. ? @ 0x00007fbc6213eac3 22. ? @ 0x00007fbc621d0850 2025.07.28 11:49:57.900469 [ 4526 ] {7f5ac58b-2ec1-4250-82d9-740ae0ce502d} executeQuery: Code: 524. DB::Exception: ALTER of partition key column x from type Int8 to type Enum8('' = 1) is not safe because it can change the representation of partition key. (ALTER_OF_COLUMN_IS_FORBIDDEN) (version 25.3.6.10636.altinitytest (altinity build)) (from [::1]:34912) (comment: 01344_alter_enum_partition_key.sql) (query 19, line 24) (in query: ALTER TABLE test MODIFY COLUMN x Enum8('' = 1);), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&) @ 0x000000000a10182b 4. /build/src/Storages/MergeTree/MergeTreeData.cpp:3821: DB::MergeTreeData::checkAlterIsPossible(DB::AlterCommands const&, std::shared_ptr) const @ 0x0000000016338c98 5. /build/src/Interpreters/InterpreterAlterQuery.cpp:215: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x00000000148deab3 6. /build/src/Interpreters/InterpreterAlterQuery.cpp:77: DB::InterpreterAlterQuery::execute() @ 0x00000000148dcb0d 7. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88dc9 8. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 9. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 10. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 11. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 12. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 13. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 14. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 15. ? @ 0x00007fbc6213eac3 16. ? @ 0x00007fbc621d0850 2025.07.28 11:49:57.913446 [ 4526 ] {} TCPHandler: Code: 524. DB::Exception: ALTER of partition key column x from type Int8 to type Enum8('' = 1) is not safe because it can change the representation of partition key. (ALTER_OF_COLUMN_IS_FORBIDDEN), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&) @ 0x000000000a10182b 4. /build/src/Storages/MergeTree/MergeTreeData.cpp:3821: DB::MergeTreeData::checkAlterIsPossible(DB::AlterCommands const&, std::shared_ptr) const @ 0x0000000016338c98 5. /build/src/Interpreters/InterpreterAlterQuery.cpp:215: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x00000000148deab3 6. /build/src/Interpreters/InterpreterAlterQuery.cpp:77: DB::InterpreterAlterQuery::execute() @ 0x00000000148dcb0d 7. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88dc9 8. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 9. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 10. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 11. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 12. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 13. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 14. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 15. ? @ 0x00007fbc6213eac3 16. ? @ 0x00007fbc621d0850 2025.07.28 11:49:58.103243 [ 4526 ] {8cddd6a1-123e-455d-ae85-44fe5001ce1d} executeQuery: Code: 524. DB::Exception: ALTER of partition key column x from type Int8 to type Enum16('' = 1) is not safe because it can change the representation of partition key. (ALTER_OF_COLUMN_IS_FORBIDDEN) (version 25.3.6.10636.altinitytest (altinity build)) (from [::1]:34912) (comment: 01344_alter_enum_partition_key.sql) (query 20, line 25) (in query: ALTER TABLE test MODIFY COLUMN x Enum16('' = 1);), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&) @ 0x000000000a10182b 4. /build/src/Storages/MergeTree/MergeTreeData.cpp:3821: DB::MergeTreeData::checkAlterIsPossible(DB::AlterCommands const&, std::shared_ptr) const @ 0x0000000016338c98 5. /build/src/Interpreters/InterpreterAlterQuery.cpp:215: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x00000000148deab3 6. /build/src/Interpreters/InterpreterAlterQuery.cpp:77: DB::InterpreterAlterQuery::execute() @ 0x00000000148dcb0d 7. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88dc9 8. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 9. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 10. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 11. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 12. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 13. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 14. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 15. ? @ 0x00007fbc6213eac3 16. ? @ 0x00007fbc621d0850 2025.07.28 11:49:58.115905 [ 4526 ] {} TCPHandler: Code: 524. DB::Exception: ALTER of partition key column x from type Int8 to type Enum16('' = 1) is not safe because it can change the representation of partition key. (ALTER_OF_COLUMN_IS_FORBIDDEN), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&) @ 0x000000000a10182b 4. /build/src/Storages/MergeTree/MergeTreeData.cpp:3821: DB::MergeTreeData::checkAlterIsPossible(DB::AlterCommands const&, std::shared_ptr) const @ 0x0000000016338c98 5. /build/src/Interpreters/InterpreterAlterQuery.cpp:215: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x00000000148deab3 6. /build/src/Interpreters/InterpreterAlterQuery.cpp:77: DB::InterpreterAlterQuery::execute() @ 0x00000000148dcb0d 7. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88dc9 8. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 9. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 10. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 11. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 12. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 13. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 14. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 15. ? @ 0x00007fbc6213eac3 16. ? @ 0x00007fbc621d0850 2025.07.28 11:49:58.186775 [ 4526 ] {0d094942-3ef0-4abc-b18a-20ce8e81b214} executeQuery: Code: 524. DB::Exception: ALTER of partition key column x from type Int8 to type UInt64 is not safe because it can change the representation of partition key. (ALTER_OF_COLUMN_IS_FORBIDDEN) (version 25.3.6.10636.altinitytest (altinity build)) (from [::1]:34912) (comment: 01344_alter_enum_partition_key.sql) (query 21, line 27) (in query: ALTER TABLE test MODIFY COLUMN x UInt64;), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&) @ 0x000000000a10182b 4. /build/src/Storages/MergeTree/MergeTreeData.cpp:3821: DB::MergeTreeData::checkAlterIsPossible(DB::AlterCommands const&, std::shared_ptr) const @ 0x0000000016338c98 5. /build/src/Interpreters/InterpreterAlterQuery.cpp:215: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x00000000148deab3 6. /build/src/Interpreters/InterpreterAlterQuery.cpp:77: DB::InterpreterAlterQuery::execute() @ 0x00000000148dcb0d 7. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88dc9 8. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 9. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 10. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 11. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 12. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 13. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 14. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 15. ? @ 0x00007fbc6213eac3 16. ? @ 0x00007fbc621d0850 2025.07.28 11:49:58.191929 [ 4526 ] {} TCPHandler: Code: 524. DB::Exception: ALTER of partition key column x from type Int8 to type UInt64 is not safe because it can change the representation of partition key. (ALTER_OF_COLUMN_IS_FORBIDDEN), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&) @ 0x000000000a10182b 4. /build/src/Storages/MergeTree/MergeTreeData.cpp:3821: DB::MergeTreeData::checkAlterIsPossible(DB::AlterCommands const&, std::shared_ptr) const @ 0x0000000016338c98 5. /build/src/Interpreters/InterpreterAlterQuery.cpp:215: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x00000000148deab3 6. /build/src/Interpreters/InterpreterAlterQuery.cpp:77: DB::InterpreterAlterQuery::execute() @ 0x00000000148dcb0d 7. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88dc9 8. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 9. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 10. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 11. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 12. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 13. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 14. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 15. ? @ 0x00007fbc6213eac3 16. ? @ 0x00007fbc621d0850 2025.07.28 11:49:58.320074 [ 4526 ] {6b517a6c-7ef4-4856-80ed-b98279d49513} executeQuery: Code: 524. DB::Exception: ALTER of partition key column x from type Int8 to type String is not safe because it can change the representation of partition key. (ALTER_OF_COLUMN_IS_FORBIDDEN) (version 25.3.6.10636.altinitytest (altinity build)) (from [::1]:34912) (comment: 01344_alter_enum_partition_key.sql) (query 22, line 28) (in query: ALTER TABLE test MODIFY COLUMN x String;), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&) @ 0x000000000a10182b 4. /build/src/Storages/MergeTree/MergeTreeData.cpp:3821: DB::MergeTreeData::checkAlterIsPossible(DB::AlterCommands const&, std::shared_ptr) const @ 0x0000000016338c98 5. /build/src/Interpreters/InterpreterAlterQuery.cpp:215: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x00000000148deab3 6. /build/src/Interpreters/InterpreterAlterQuery.cpp:77: DB::InterpreterAlterQuery::execute() @ 0x00000000148dcb0d 7. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88dc9 8. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 9. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 10. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 11. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 12. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 13. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 14. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 15. ? @ 0x00007fbc6213eac3 16. ? @ 0x00007fbc621d0850 2025.07.28 11:49:58.325363 [ 4526 ] {} TCPHandler: Code: 524. DB::Exception: ALTER of partition key column x from type Int8 to type String is not safe because it can change the representation of partition key. (ALTER_OF_COLUMN_IS_FORBIDDEN), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&) @ 0x000000000a10182b 4. /build/src/Storages/MergeTree/MergeTreeData.cpp:3821: DB::MergeTreeData::checkAlterIsPossible(DB::AlterCommands const&, std::shared_ptr) const @ 0x0000000016338c98 5. /build/src/Interpreters/InterpreterAlterQuery.cpp:215: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x00000000148deab3 6. /build/src/Interpreters/InterpreterAlterQuery.cpp:77: DB::InterpreterAlterQuery::execute() @ 0x00000000148dcb0d 7. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88dc9 8. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 9. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 10. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 11. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 12. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 13. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 14. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 15. ? @ 0x00007fbc6213eac3 16. ? @ 0x00007fbc621d0850 2025.07.28 11:49:58.445467 [ 4526 ] {5e19e3b8-f434-4b73-9683-a03d1dc107b3} executeQuery: Code: 524. DB::Exception: ALTER of partition key column x from type Int8 to type Nullable(Int64) is not safe because it can change the representation of partition key. (ALTER_OF_COLUMN_IS_FORBIDDEN) (version 25.3.6.10636.altinitytest (altinity build)) (from [::1]:34912) (comment: 01344_alter_enum_partition_key.sql) (query 23, line 29) (in query: ALTER TABLE test MODIFY COLUMN x Nullable(Int64);), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&) @ 0x000000000a10182b 4. /build/src/Storages/MergeTree/MergeTreeData.cpp:3821: DB::MergeTreeData::checkAlterIsPossible(DB::AlterCommands const&, std::shared_ptr) const @ 0x0000000016338c98 5. /build/src/Interpreters/InterpreterAlterQuery.cpp:215: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x00000000148deab3 6. /build/src/Interpreters/InterpreterAlterQuery.cpp:77: DB::InterpreterAlterQuery::execute() @ 0x00000000148dcb0d 7. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88dc9 8. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 9. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 10. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 11. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 12. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 13. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 14. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 15. ? @ 0x00007fbc6213eac3 16. ? @ 0x00007fbc621d0850 2025.07.28 11:49:58.503490 [ 4526 ] {} TCPHandler: Code: 524. DB::Exception: ALTER of partition key column x from type Int8 to type Nullable(Int64) is not safe because it can change the representation of partition key. (ALTER_OF_COLUMN_IS_FORBIDDEN), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&) @ 0x000000000a10182b 4. /build/src/Storages/MergeTree/MergeTreeData.cpp:3821: DB::MergeTreeData::checkAlterIsPossible(DB::AlterCommands const&, std::shared_ptr) const @ 0x0000000016338c98 5. /build/src/Interpreters/InterpreterAlterQuery.cpp:215: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x00000000148deab3 6. /build/src/Interpreters/InterpreterAlterQuery.cpp:77: DB::InterpreterAlterQuery::execute() @ 0x00000000148dcb0d 7. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88dc9 8. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 9. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 10. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 11. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 12. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 13. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 14. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 15. ? @ 0x00007fbc6213eac3 16. ? @ 0x00007fbc621d0850 2025.07.28 11:49:58.574183 [ 4526 ] {320f5843-8807-41d7-8b44-19916c91779f} executeQuery: Code: 524. DB::Exception: Trying to ALTER RENAME key x column which is a part of key expression. (ALTER_OF_COLUMN_IS_FORBIDDEN) (version 25.3.6.10636.altinitytest (altinity build)) (from [::1]:34912) (comment: 01344_alter_enum_partition_key.sql) (query 24, line 31) (in query: ALTER TABLE test RENAME COLUMN x TO z;), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x000000000a06b56b 4. /build/src/Storages/MergeTree/MergeTreeData.cpp:3729: DB::MergeTreeData::checkAlterIsPossible(DB::AlterCommands const&, std::shared_ptr) const @ 0x00000000163380fb 5. /build/src/Interpreters/InterpreterAlterQuery.cpp:215: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x00000000148deab3 6. /build/src/Interpreters/InterpreterAlterQuery.cpp:77: DB::InterpreterAlterQuery::execute() @ 0x00000000148dcb0d 7. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88dc9 8. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 9. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 10. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 11. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 12. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 13. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 14. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 15. ? @ 0x00007fbc6213eac3 16. ? @ 0x00007fbc621d0850 2025.07.28 11:49:58.577946 [ 4526 ] {} TCPHandler: Code: 524. DB::Exception: Trying to ALTER RENAME key x 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. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x000000000a06b56b 4. /build/src/Storages/MergeTree/MergeTreeData.cpp:3729: DB::MergeTreeData::checkAlterIsPossible(DB::AlterCommands const&, std::shared_ptr) const @ 0x00000000163380fb 5. /build/src/Interpreters/InterpreterAlterQuery.cpp:215: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x00000000148deab3 6. /build/src/Interpreters/InterpreterAlterQuery.cpp:77: DB::InterpreterAlterQuery::execute() @ 0x00000000148dcb0d 7. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88dc9 8. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 9. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 10. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 11. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 12. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 13. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 14. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 15. ? @ 0x00007fbc6213eac3 16. ? @ 0x00007fbc621d0850 2025.07.28 11:49:58.646531 [ 4900 ] {8018a5f2-abbd-46d2-82da-193cb64aaa09} executeQuery: Code: 386. DB::Exception: There is no supertype for types String, UInt8 because some of them are String/FixedString/Enum and some of them are not. (NO_COMMON_TYPE) (version 25.3.6.10636.altinitytest (altinity build)) (from [::1]:35412) (comment: 01450_set_null_const.sql) (query 4, line 5) (in query: SELECT count() FROM test_mtree WHERE x = NULL;), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception>&>(int, FormatStringHelperImpl::type, std::type_identity>&>::type>, String&&, std::basic_string_view>&) @ 0x000000000de9098b 4. /build/src/DataTypes/getLeastSupertype.cpp:69: std::shared_ptr DB::(anonymous namespace)::throwOrReturn<(DB::LeastSupertypeOnError)0, std::vector, std::allocator>>>(std::vector, std::allocator>> const&, std::basic_string_view>, int) @ 0x0000000013c6a73e 5. /build/src/DataTypes/getLeastSupertype.cpp:547: std::shared_ptr DB::getLeastSupertype<(DB::LeastSupertypeOnError)0>(std::vector, std::allocator>> const&) @ 0x0000000013c6dd15 6. /build/src/Functions/FunctionsComparison.h:1149: DB::FunctionComparison::executeGeneric(DB::ColumnWithTypeAndName const&, DB::ColumnWithTypeAndName const&) const @ 0x000000000b674913 7. /build/src/Functions/FunctionsComparison.h:1429: DB::FunctionComparison::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000b65b6d4 8. /build/src/Functions/IFunction.h:437: DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000a069f2a 9. /build/src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000012d9965a 10. /build/src/Functions/IFunction.cpp:351: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d93b02 11. /build/src/Functions/IFunction.cpp:420: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d95059 12. /build/src/Functions/IFunction.cpp:498: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d95c72 13. /build/src/Interpreters/ActionsDAG.cpp:812: DB::ActionsDAG::evaluatePartialResult(std::unordered_map, std::equal_to, std::allocator>>&, std::vector> const&, unsigned long, bool) @ 0x0000000013fa38cc 14. /build/src/Interpreters/ActionsDAG.cpp:892: DB::ActionsDAG::updateHeader(DB::Block const&) const @ 0x0000000013fa29a8 15. /build/src/Processors/QueryPlan/SourceStepWithFilter.cpp:39: DB::SourceStepWithFilter::applyPrewhereActions(DB::Block, std::shared_ptr const&) @ 0x0000000016ea055e 16. /build/src/Storages/MergeTree/MergeTreeSelectProcessor.cpp:265: DB::MergeTreeSelectProcessor::transformHeader(DB::Block, std::shared_ptr const&) @ 0x00000000164c05c4 17. /build/src/Processors/QueryPlan/ReadFromMergeTree.cpp:348: 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) @ 0x0000000016e1c7c7 18. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107], 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&) @ 0x0000000016401cd2 19. /build/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 @ 0x00000000163ec114 20. /build/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 @ 0x00000000163ebef8 21. /build/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) @ 0x0000000016635568 22. /build/src/Planner/PlannerJoinTree.cpp:946: DB::(anonymous namespace)::buildQueryPlanForTableExpression(std::shared_ptr, std::shared_ptr const&, DB::SelectQueryInfo const&, DB::SelectQueryOptions const&, std::shared_ptr&, bool, bool) @ 0x00000000149970ee 23. /build/src/Planner/PlannerJoinTree.cpp:2252: DB::buildJoinTreeQueryPlan(std::shared_ptr const&, DB::SelectQueryInfo const&, DB::SelectQueryOptions&, std::unordered_set, std::equal_to, std::allocator> const&, std::shared_ptr&) @ 0x000000001498e109 24. /build/src/Planner/Planner.cpp:1553: DB::Planner::buildPlanForQueryNode() @ 0x0000000014979dae 25. /build/src/Planner/Planner.cpp:1308: DB::Planner::buildQueryPlanIfNeeded() @ 0x000000001497685c 26. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:255: DB::InterpreterSelectQueryAnalyzer::getQueryPlan() @ 0x000000001497476d 27. /build/src/Interpreters/executeQuery.cpp:1405: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88806 28. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 29. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 30. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 31. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 2025.07.28 11:49:58.672204 [ 4900 ] {} TCPHandler: Code: 386. DB::Exception: There is no supertype for types String, UInt8 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. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception>&>(int, FormatStringHelperImpl::type, std::type_identity>&>::type>, String&&, std::basic_string_view>&) @ 0x000000000de9098b 4. /build/src/DataTypes/getLeastSupertype.cpp:69: std::shared_ptr DB::(anonymous namespace)::throwOrReturn<(DB::LeastSupertypeOnError)0, std::vector, std::allocator>>>(std::vector, std::allocator>> const&, std::basic_string_view>, int) @ 0x0000000013c6a73e 5. /build/src/DataTypes/getLeastSupertype.cpp:547: std::shared_ptr DB::getLeastSupertype<(DB::LeastSupertypeOnError)0>(std::vector, std::allocator>> const&) @ 0x0000000013c6dd15 6. /build/src/Functions/FunctionsComparison.h:1149: DB::FunctionComparison::executeGeneric(DB::ColumnWithTypeAndName const&, DB::ColumnWithTypeAndName const&) const @ 0x000000000b674913 7. /build/src/Functions/FunctionsComparison.h:1429: DB::FunctionComparison::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000b65b6d4 8. /build/src/Functions/IFunction.h:437: DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000a069f2a 9. /build/src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000012d9965a 10. /build/src/Functions/IFunction.cpp:351: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d93b02 11. /build/src/Functions/IFunction.cpp:420: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d95059 12. /build/src/Functions/IFunction.cpp:498: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d95c72 13. /build/src/Interpreters/ActionsDAG.cpp:812: DB::ActionsDAG::evaluatePartialResult(std::unordered_map, std::equal_to, std::allocator>>&, std::vector> const&, unsigned long, bool) @ 0x0000000013fa38cc 14. /build/src/Interpreters/ActionsDAG.cpp:892: DB::ActionsDAG::updateHeader(DB::Block const&) const @ 0x0000000013fa29a8 15. /build/src/Processors/QueryPlan/SourceStepWithFilter.cpp:39: DB::SourceStepWithFilter::applyPrewhereActions(DB::Block, std::shared_ptr const&) @ 0x0000000016ea055e 16. /build/src/Storages/MergeTree/MergeTreeSelectProcessor.cpp:265: DB::MergeTreeSelectProcessor::transformHeader(DB::Block, std::shared_ptr const&) @ 0x00000000164c05c4 17. /build/src/Processors/QueryPlan/ReadFromMergeTree.cpp:348: 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) @ 0x0000000016e1c7c7 18. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107], 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&) @ 0x0000000016401cd2 19. /build/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 @ 0x00000000163ec114 20. /build/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 @ 0x00000000163ebef8 21. /build/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) @ 0x0000000016635568 22. /build/src/Planner/PlannerJoinTree.cpp:946: DB::(anonymous namespace)::buildQueryPlanForTableExpression(std::shared_ptr, std::shared_ptr const&, DB::SelectQueryInfo const&, DB::SelectQueryOptions const&, std::shared_ptr&, bool, bool) @ 0x00000000149970ee 23. /build/src/Planner/PlannerJoinTree.cpp:2252: DB::buildJoinTreeQueryPlan(std::shared_ptr const&, DB::SelectQueryInfo const&, DB::SelectQueryOptions&, std::unordered_set, std::equal_to, std::allocator> const&, std::shared_ptr&) @ 0x000000001498e109 24. /build/src/Planner/Planner.cpp:1553: DB::Planner::buildPlanForQueryNode() @ 0x0000000014979dae 25. /build/src/Planner/Planner.cpp:1308: DB::Planner::buildQueryPlanIfNeeded() @ 0x000000001497685c 26. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:255: DB::InterpreterSelectQueryAnalyzer::getQueryPlan() @ 0x000000001497476d 27. /build/src/Interpreters/executeQuery.cpp:1405: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88806 28. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 29. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 30. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 31. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 2025.07.28 11:49:58.690776 [ 4526 ] {e55057ec-785a-4a7d-9a5f-e8b63a5c96e9} executeQuery: Code: 524. DB::Exception: Trying to ALTER RENAME key y column which is a part of key expression. (ALTER_OF_COLUMN_IS_FORBIDDEN) (version 25.3.6.10636.altinitytest (altinity build)) (from [::1]:34912) (comment: 01344_alter_enum_partition_key.sql) (query 25, line 32) (in query: ALTER TABLE test RENAME COLUMN y TO z;), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x000000000a06b56b 4. /build/src/Storages/MergeTree/MergeTreeData.cpp:3729: DB::MergeTreeData::checkAlterIsPossible(DB::AlterCommands const&, std::shared_ptr) const @ 0x00000000163380fb 5. /build/src/Interpreters/InterpreterAlterQuery.cpp:215: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x00000000148deab3 6. /build/src/Interpreters/InterpreterAlterQuery.cpp:77: DB::InterpreterAlterQuery::execute() @ 0x00000000148dcb0d 7. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88dc9 8. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 9. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 10. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 11. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 12. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 13. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 14. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 15. ? @ 0x00007fbc6213eac3 16. ? @ 0x00007fbc621d0850 2025.07.28 11:49:58.709689 [ 4526 ] {} TCPHandler: Code: 524. DB::Exception: Trying to ALTER RENAME key y 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. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x000000000a06b56b 4. /build/src/Storages/MergeTree/MergeTreeData.cpp:3729: DB::MergeTreeData::checkAlterIsPossible(DB::AlterCommands const&, std::shared_ptr) const @ 0x00000000163380fb 5. /build/src/Interpreters/InterpreterAlterQuery.cpp:215: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x00000000148deab3 6. /build/src/Interpreters/InterpreterAlterQuery.cpp:77: DB::InterpreterAlterQuery::execute() @ 0x00000000148dcb0d 7. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88dc9 8. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 9. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 10. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 11. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 12. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 13. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 14. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 15. ? @ 0x00007fbc6213eac3 16. ? @ 0x00007fbc621d0850 2025.07.28 11:49:58.943451 [ 4526 ] {f6657bbb-bb2e-444c-af85-cc980bcbb4aa} executeQuery: Code: 47. DB::Exception: Missing columns: 'x' while processing: 'x', required columns: 'x', available columns: 'y'. (UNKNOWN_IDENTIFIER) (version 25.3.6.10636.altinitytest (altinity build)) (from [::1]:34912) (comment: 01344_alter_enum_partition_key.sql) (query 26, line 33) (in query: ALTER TABLE test DROP COLUMN x;), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Interpreters/TreeRewriter.cpp:1303: DB::TreeRewriterResult::collectUsedColumns(std::shared_ptr const&, bool, bool) @ 0x0000000014c01fc8 4. /build/src/Interpreters/TreeRewriter.cpp:1561: DB::TreeRewriter::analyze(std::shared_ptr&, DB::NamesAndTypesList const&, std::shared_ptr, std::shared_ptr const&, bool, bool, bool, bool) const @ 0x0000000014c0a438 5. /build/src/Storages/KeyDescription.cpp:163: DB::KeyDescription::getSortingKeyFromAST(std::shared_ptr const&, DB::ColumnsDescription const&, std::shared_ptr, std::optional const&) @ 0x0000000015d2e395 6. /build/src/Storages/KeyDescription.cpp:78: DB::KeyDescription::recalculateWithNewAST(std::shared_ptr const&, DB::ColumnsDescription const&, std::shared_ptr) @ 0x0000000015d2db0f 7. /build/src/Storages/AlterCommands.cpp:1280: DB::AlterCommands::apply(DB::StorageInMemoryMetadata&, std::shared_ptr) const @ 0x0000000015cf2d52 8. /build/src/Storages/MergeTree/MergeTreeData.cpp:3534: DB::MergeTreeData::checkAlterIsPossible(DB::AlterCommands const&, std::shared_ptr) const @ 0x00000000163355eb 9. /build/src/Interpreters/InterpreterAlterQuery.cpp:215: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x00000000148deab3 10. /build/src/Interpreters/InterpreterAlterQuery.cpp:77: DB::InterpreterAlterQuery::execute() @ 0x00000000148dcb0d 11. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88dc9 12. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 13. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 14. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 15. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 16. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 17. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 18. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 19. ? @ 0x00007fbc6213eac3 20. ? @ 0x00007fbc621d0850 2025.07.28 11:49:58.946735 [ 4526 ] {} TCPHandler: Code: 47. DB::Exception: Missing columns: 'x' while processing: 'x', required columns: 'x', available columns: 'y'. (UNKNOWN_IDENTIFIER), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Interpreters/TreeRewriter.cpp:1303: DB::TreeRewriterResult::collectUsedColumns(std::shared_ptr const&, bool, bool) @ 0x0000000014c01fc8 4. /build/src/Interpreters/TreeRewriter.cpp:1561: DB::TreeRewriter::analyze(std::shared_ptr&, DB::NamesAndTypesList const&, std::shared_ptr, std::shared_ptr const&, bool, bool, bool, bool) const @ 0x0000000014c0a438 5. /build/src/Storages/KeyDescription.cpp:163: DB::KeyDescription::getSortingKeyFromAST(std::shared_ptr const&, DB::ColumnsDescription const&, std::shared_ptr, std::optional const&) @ 0x0000000015d2e395 6. /build/src/Storages/KeyDescription.cpp:78: DB::KeyDescription::recalculateWithNewAST(std::shared_ptr const&, DB::ColumnsDescription const&, std::shared_ptr) @ 0x0000000015d2db0f 7. /build/src/Storages/AlterCommands.cpp:1280: DB::AlterCommands::apply(DB::StorageInMemoryMetadata&, std::shared_ptr) const @ 0x0000000015cf2d52 8. /build/src/Storages/MergeTree/MergeTreeData.cpp:3534: DB::MergeTreeData::checkAlterIsPossible(DB::AlterCommands const&, std::shared_ptr) const @ 0x00000000163355eb 9. /build/src/Interpreters/InterpreterAlterQuery.cpp:215: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x00000000148deab3 10. /build/src/Interpreters/InterpreterAlterQuery.cpp:77: DB::InterpreterAlterQuery::execute() @ 0x00000000148dcb0d 11. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88dc9 12. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 13. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 14. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 15. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 16. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 17. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 18. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 19. ? @ 0x00007fbc6213eac3 20. ? @ 0x00007fbc621d0850 2025.07.28 11:49:59.111392 [ 4526 ] {160d6a16-7447-4ec5-8e46-d3f0396cb8cb} executeQuery: Code: 47. DB::Exception: Missing columns: 'y' while processing: 'y', required columns: 'y', available columns: 'x'. (UNKNOWN_IDENTIFIER) (version 25.3.6.10636.altinitytest (altinity build)) (from [::1]:34912) (comment: 01344_alter_enum_partition_key.sql) (query 27, line 34) (in query: ALTER TABLE test DROP COLUMN y;), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Interpreters/TreeRewriter.cpp:1303: DB::TreeRewriterResult::collectUsedColumns(std::shared_ptr const&, bool, bool) @ 0x0000000014c01fc8 4. /build/src/Interpreters/TreeRewriter.cpp:1561: DB::TreeRewriter::analyze(std::shared_ptr&, DB::NamesAndTypesList const&, std::shared_ptr, std::shared_ptr const&, bool, bool, bool, bool) const @ 0x0000000014c0a438 5. /build/src/Storages/KeyDescription.cpp:163: DB::KeyDescription::getSortingKeyFromAST(std::shared_ptr const&, DB::ColumnsDescription const&, std::shared_ptr, std::optional const&) @ 0x0000000015d2e395 6. /build/src/Storages/KeyDescription.cpp:78: DB::KeyDescription::recalculateWithNewAST(std::shared_ptr const&, DB::ColumnsDescription const&, std::shared_ptr) @ 0x0000000015d2db0f 7. /build/src/Storages/AlterCommands.cpp:1266: DB::AlterCommands::apply(DB::StorageInMemoryMetadata&, std::shared_ptr) const @ 0x0000000015cf2cd5 8. /build/src/Storages/MergeTree/MergeTreeData.cpp:3534: DB::MergeTreeData::checkAlterIsPossible(DB::AlterCommands const&, std::shared_ptr) const @ 0x00000000163355eb 9. /build/src/Interpreters/InterpreterAlterQuery.cpp:215: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x00000000148deab3 10. /build/src/Interpreters/InterpreterAlterQuery.cpp:77: DB::InterpreterAlterQuery::execute() @ 0x00000000148dcb0d 11. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88dc9 12. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 13. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 14. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 15. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 16. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 17. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 18. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 19. ? @ 0x00007fbc6213eac3 20. ? @ 0x00007fbc621d0850 2025.07.28 11:49:59.145176 [ 4526 ] {} TCPHandler: Code: 47. DB::Exception: Missing columns: 'y' while processing: 'y', required columns: 'y', available columns: 'x'. (UNKNOWN_IDENTIFIER), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Interpreters/TreeRewriter.cpp:1303: DB::TreeRewriterResult::collectUsedColumns(std::shared_ptr const&, bool, bool) @ 0x0000000014c01fc8 4. /build/src/Interpreters/TreeRewriter.cpp:1561: DB::TreeRewriter::analyze(std::shared_ptr&, DB::NamesAndTypesList const&, std::shared_ptr, std::shared_ptr const&, bool, bool, bool, bool) const @ 0x0000000014c0a438 5. /build/src/Storages/KeyDescription.cpp:163: DB::KeyDescription::getSortingKeyFromAST(std::shared_ptr const&, DB::ColumnsDescription const&, std::shared_ptr, std::optional const&) @ 0x0000000015d2e395 6. /build/src/Storages/KeyDescription.cpp:78: DB::KeyDescription::recalculateWithNewAST(std::shared_ptr const&, DB::ColumnsDescription const&, std::shared_ptr) @ 0x0000000015d2db0f 7. /build/src/Storages/AlterCommands.cpp:1266: DB::AlterCommands::apply(DB::StorageInMemoryMetadata&, std::shared_ptr) const @ 0x0000000015cf2cd5 8. /build/src/Storages/MergeTree/MergeTreeData.cpp:3534: DB::MergeTreeData::checkAlterIsPossible(DB::AlterCommands const&, std::shared_ptr) const @ 0x00000000163355eb 9. /build/src/Interpreters/InterpreterAlterQuery.cpp:215: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x00000000148deab3 10. /build/src/Interpreters/InterpreterAlterQuery.cpp:77: DB::InterpreterAlterQuery::execute() @ 0x00000000148dcb0d 11. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88dc9 12. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 13. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 14. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 15. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 16. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 17. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 18. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 19. ? @ 0x00007fbc6213eac3 20. ? @ 0x00007fbc621d0850 2025.07.28 11:49:59.597923 [ 4581 ] {6f3611ba-42b2-4165-832d-140dea7a4836} executeQuery: Code: 47. DB::Exception: Unknown expression or function identifier `x` in scope x = 1. (UNKNOWN_IDENTIFIER) (version 25.3.6.10636.altinitytest (altinity build)) (from [::1]:35432) (comment: 01883_grouping_sets_crash.sql) (query 4, line 14) (in query: -- { echoOn } SELECT fact_3_id, fact_4_id FROM grouping_sets GROUP BY GROUPING SETS ( ('wo\0ldworldwo\0ldworld'), (fact_3_id, fact_4_id)) ORDER BY fact_3_id, fact_4_id;), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.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&&) @ 0x000000001404b3b9 4. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3771: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000001401b849 5. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3980: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000014018e31 6. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:2925: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000001402fcbd 7. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3838: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000014019a9e 8. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:209: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000001401270e 9. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000014011fce 10. /build/src/Planner/Utils.cpp:458: DB::buildFilterInfo(std::shared_ptr, std::shared_ptr const&, std::shared_ptr&, std::unordered_set, std::equal_to, std::allocator>) @ 0x0000000013fe8bcf 11. /build/src/Planner/PlannerJoinTree.cpp:535: DB::(anonymous namespace)::buildQueryPlanForTableExpression(std::shared_ptr, std::shared_ptr const&, DB::SelectQueryInfo const&, DB::SelectQueryOptions const&, std::shared_ptr&, bool, bool) @ 0x00000000149956d3 12. /build/src/Planner/PlannerJoinTree.cpp:2252: DB::buildJoinTreeQueryPlan(std::shared_ptr const&, DB::SelectQueryInfo const&, DB::SelectQueryOptions&, std::unordered_set, std::equal_to, std::allocator> const&, std::shared_ptr&) @ 0x000000001498e109 13. /build/src/Planner/Planner.cpp:1553: DB::Planner::buildPlanForQueryNode() @ 0x0000000014979dae 14. /build/src/Planner/Planner.cpp:1308: DB::Planner::buildQueryPlanIfNeeded() @ 0x000000001497685c 15. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:255: DB::InterpreterSelectQueryAnalyzer::getQueryPlan() @ 0x000000001497476d 16. /build/src/Interpreters/executeQuery.cpp:1405: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88806 17. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 18. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 19. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 20. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 21. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 22. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 23. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 24. ? @ 0x00007fbc6213eac3 25. ? @ 0x00007fbc621d0850 2025.07.28 11:49:59.624022 [ 4581 ] {} TCPHandler: Code: 47. DB::Exception: Unknown expression or function identifier `x` in scope x = 1. (UNKNOWN_IDENTIFIER), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.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&&) @ 0x000000001404b3b9 4. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3771: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000001401b849 5. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3980: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000014018e31 6. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:2925: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000001402fcbd 7. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3838: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000014019a9e 8. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:209: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000001401270e 9. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000014011fce 10. /build/src/Planner/Utils.cpp:458: DB::buildFilterInfo(std::shared_ptr, std::shared_ptr const&, std::shared_ptr&, std::unordered_set, std::equal_to, std::allocator>) @ 0x0000000013fe8bcf 11. /build/src/Planner/PlannerJoinTree.cpp:535: DB::(anonymous namespace)::buildQueryPlanForTableExpression(std::shared_ptr, std::shared_ptr const&, DB::SelectQueryInfo const&, DB::SelectQueryOptions const&, std::shared_ptr&, bool, bool) @ 0x00000000149956d3 12. /build/src/Planner/PlannerJoinTree.cpp:2252: DB::buildJoinTreeQueryPlan(std::shared_ptr const&, DB::SelectQueryInfo const&, DB::SelectQueryOptions&, std::unordered_set, std::equal_to, std::allocator> const&, std::shared_ptr&) @ 0x000000001498e109 13. /build/src/Planner/Planner.cpp:1553: DB::Planner::buildPlanForQueryNode() @ 0x0000000014979dae 14. /build/src/Planner/Planner.cpp:1308: DB::Planner::buildQueryPlanIfNeeded() @ 0x000000001497685c 15. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:255: DB::InterpreterSelectQueryAnalyzer::getQueryPlan() @ 0x000000001497476d 16. /build/src/Interpreters/executeQuery.cpp:1405: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88806 17. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 18. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 19. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 20. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 21. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 22. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 23. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 24. ? @ 0x00007fbc6213eac3 25. ? @ 0x00007fbc621d0850 2025.07.28 11:50:01.198972 [ 4446 ] {} 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. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception>&, String>(int, FormatStringHelperImpl>&>::type, std::type_identity::type>, std::basic_string_view>&, String&&) @ 0x000000001385a5eb 4. /build/src/Access/SettingsConstraints.cpp:376: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000013859b18 5. /build/src/Access/SettingsConstraints.cpp:300: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000013858faf 6. /build/src/Access/SettingsConstraints.cpp:209: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000013859223 7. /build/src/Interpreters/Context.cpp:2690: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000014436134 8. /build/src/Interpreters/Context.cpp:2729: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x000000001443662b 9. /build/src/Server/HTTPHandler.cpp:457: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000001686d165 10. /build/src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x0000000016870807 11. /build/src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x0000000016907e99 12. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 13. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 14. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 15. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 16. ? @ 0x00007fbc6213eac3 17. ? @ 0x00007fbc621d0850 (version 25.3.6.10636.altinitytest (altinity build)) 2025.07.28 11:50:01.291375 [ 4580 ] {d2eff2cb-1dc8-4369-a5b5-1ff829424f9a} executeQuery: Code: 36. DB::Exception: 'StorageFuzzJSON' supports only columns of String type, got Nullable(Int64). (BAD_ARGUMENTS) (version 25.3.6.10636.altinitytest (altinity build)) (from [::1]:35484) (comment: 02919_storage_fuzzjson.sql) (query 14, line 48) (in query: CREATE TABLE 02919_test_table_invalid_col_type ( str Nullable(Int64) ) ENGINE = FuzzJSON('{"pet":"rat"}', NULL);), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x000000000a06b56b 4. /build/src/Storages/StorageFuzzJSON.cpp:735: std::shared_ptr std::__function::__policy_invoker (DB::StorageFactory::Arguments const&)>::__call_impl[abi:se190107] (DB::StorageFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::StorageFactory::Arguments const&) @ 0x0000000015da9e57 5. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000015d81ea2 6. /build/src/Interpreters/InterpreterCreateQuery.cpp:1945: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x00000000149009bb 7. /build/src/Interpreters/InterpreterCreateQuery.cpp:1743: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000148f9aa9 8. /build/src/Interpreters/InterpreterCreateQuery.cpp:2352: DB::InterpreterCreateQuery::execute() @ 0x0000000014905a41 9. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88dc9 10. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 11. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 12. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 13. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 14. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 16. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 17. ? @ 0x00007fbc6213eac3 18. ? @ 0x00007fbc621d0850 2025.07.28 11:50:01.319033 [ 4580 ] {} TCPHandler: Code: 36. DB::Exception: 'StorageFuzzJSON' supports only columns of String type, got Nullable(Int64). (BAD_ARGUMENTS), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x000000000a06b56b 4. /build/src/Storages/StorageFuzzJSON.cpp:735: std::shared_ptr std::__function::__policy_invoker (DB::StorageFactory::Arguments const&)>::__call_impl[abi:se190107] (DB::StorageFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::StorageFactory::Arguments const&) @ 0x0000000015da9e57 5. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000015d81ea2 6. /build/src/Interpreters/InterpreterCreateQuery.cpp:1945: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x00000000149009bb 7. /build/src/Interpreters/InterpreterCreateQuery.cpp:1743: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000148f9aa9 8. /build/src/Interpreters/InterpreterCreateQuery.cpp:2352: DB::InterpreterCreateQuery::execute() @ 0x0000000014905a41 9. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88dc9 10. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 11. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 12. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 13. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 14. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 16. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 17. ? @ 0x00007fbc6213eac3 18. ? @ 0x00007fbc621d0850 2025.07.28 11:50:01.497273 [ 4474 ] {ef579622-f400-4237-bd84-87f6dcde640b} executeQuery: Code: 219. DB::Exception: New table appeared in database being dropped or detached. Try again. (DATABASE_NOT_EMPTY) (version 25.3.6.10636.altinitytest (altinity build)) (from [::1]:50872) (comment: 02008_test_union_distinct_in_subquery.sql) (in query: DROP DATABASE IF EXISTS test_a4tcofnt SYNC ), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000000a074fcb 4. /build/src/Interpreters/DatabaseCatalog.cpp:608: DB::DatabaseCatalog::detachDatabase(std::shared_ptr, String const&, bool, bool) @ 0x00000000144f41b9 5. /build/src/Interpreters/InterpreterDropQuery.cpp:482: DB::InterpreterDropQuery::executeToDatabaseImpl(DB::ASTDropQuery const&, std::shared_ptr&, std::vector, DB::UUIDTag>, std::allocator, DB::UUIDTag>>>&) @ 0x00000000149179be 6. /build/src/Interpreters/InterpreterDropQuery.cpp:363: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x0000000014913988 7. /build/src/Interpreters/InterpreterDropQuery.cpp:99: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000014913142 8. /build/src/Interpreters/InterpreterDropQuery.cpp:72: DB::InterpreterDropQuery::execute() @ 0x0000000014912b65 9. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88dc9 10. /build/src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x0000000014c8ca7b 11. /build/src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000001686da12 12. /build/src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x0000000016870807 13. /build/src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x0000000016907e99 14. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 15. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 16. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 17. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 18. ? @ 0x00007fbc6213eac3 19. ? @ 0x00007fbc621d0850 2025.07.28 11:50:01.508318 [ 4474 ] {ef579622-f400-4237-bd84-87f6dcde640b} 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. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000000a074fcb 4. /build/src/Interpreters/DatabaseCatalog.cpp:608: DB::DatabaseCatalog::detachDatabase(std::shared_ptr, String const&, bool, bool) @ 0x00000000144f41b9 5. /build/src/Interpreters/InterpreterDropQuery.cpp:482: DB::InterpreterDropQuery::executeToDatabaseImpl(DB::ASTDropQuery const&, std::shared_ptr&, std::vector, DB::UUIDTag>, std::allocator, DB::UUIDTag>>>&) @ 0x00000000149179be 6. /build/src/Interpreters/InterpreterDropQuery.cpp:363: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x0000000014913988 7. /build/src/Interpreters/InterpreterDropQuery.cpp:99: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000014913142 8. /build/src/Interpreters/InterpreterDropQuery.cpp:72: DB::InterpreterDropQuery::execute() @ 0x0000000014912b65 9. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88dc9 10. /build/src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x0000000014c8ca7b 11. /build/src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000001686da12 12. /build/src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x0000000016870807 13. /build/src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x0000000016907e99 14. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 15. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 16. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 17. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 18. ? @ 0x00007fbc6213eac3 19. ? @ 0x00007fbc621d0850 (version 25.3.6.10636.altinitytest (altinity build)) 2025.07.28 11:50:01.514120 [ 6138 ] {b5d9b973-4d3c-411c-b51b-ed9c1436d706} executeQuery: Code: 47. DB::Exception: Unknown expression or function identifier `x` in scope x = 1. (UNKNOWN_IDENTIFIER) (version 25.3.6.10636.altinitytest (altinity build)) (from [::1]:35514) (comment: 03262_filter_push_down_view.sql) (query 9, line 36) (in query: select trimLeft(explain) from (EXPLAIN indexes = 1 SELECT auid FROM alpha__day WHERE auid = 1) where explain like '%Condition:%' or explain like '%Granules:%' settings allow_experimental_analyzer = 1;), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.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&&) @ 0x000000001404b3b9 4. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3771: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000001401b849 5. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3980: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000014018e31 6. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:2925: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000001402fcbd 7. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3838: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000014019a9e 8. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:209: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000001401270e 9. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000014011fce 10. /build/src/Planner/Utils.cpp:458: DB::buildFilterInfo(std::shared_ptr, std::shared_ptr const&, std::shared_ptr&, std::unordered_set, std::equal_to, std::allocator>) @ 0x0000000013fe8bcf 11. /build/src/Planner/PlannerJoinTree.cpp:535: DB::(anonymous namespace)::buildQueryPlanForTableExpression(std::shared_ptr, std::shared_ptr const&, DB::SelectQueryInfo const&, DB::SelectQueryOptions const&, std::shared_ptr&, bool, bool) @ 0x00000000149956d3 12. /build/src/Planner/PlannerJoinTree.cpp:2252: DB::buildJoinTreeQueryPlan(std::shared_ptr const&, DB::SelectQueryInfo const&, DB::SelectQueryOptions&, std::unordered_set, std::equal_to, std::allocator> const&, std::shared_ptr&) @ 0x000000001498e109 13. /build/src/Planner/Planner.cpp:1553: DB::Planner::buildPlanForQueryNode() @ 0x0000000014979dae 14. /build/src/Planner/Planner.cpp:1308: DB::Planner::buildQueryPlanIfNeeded() @ 0x000000001497685c 15. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:261: DB::InterpreterSelectQueryAnalyzer::extractQueryPlan() && @ 0x000000001497478d 16. /build/src/Interpreters/InterpreterExplainQuery.cpp:509: DB::InterpreterExplainQuery::executeImpl() @ 0x000000001491b92e 17. /build/src/Interpreters/InterpreterExplainQuery.cpp:130: DB::InterpreterExplainQuery::execute() @ 0x0000000014919fc7 18. /build/src/TableFunctions/TableFunctionExplain.cpp:180: DB::(anonymous namespace)::TableFunctionExplain::executeImpl(std::shared_ptr const&, std::shared_ptr, String const&, DB::ColumnsDescription, bool) const @ 0x000000001185d51e 19. /build/src/TableFunctions/ITableFunction.cpp:36: DB::ITableFunction::execute(std::shared_ptr const&, std::shared_ptr, String const&, DB::ColumnsDescription, bool, bool) const @ 0x00000000131e9fc3 20. /build/src/Interpreters/Context.cpp:2501: DB::Context::executeTableFunction(std::shared_ptr const&, std::shared_ptr const&) @ 0x00000000144345b2 21. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:4975: DB::QueryAnalyzer::resolveTableFunction(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&, bool) @ 0x000000001401e9f9 22. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5342: DB::QueryAnalyzer::resolveQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&) @ 0x00000000140452bf 23. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5597: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000140136f0 24. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3870: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x00000000140199de 25. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5334: DB::QueryAnalyzer::resolveQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&) @ 0x00000000140454b0 26. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5597: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000140136f0 27. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000140127f9 28. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000014011fce 29. /build/src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000001406ce8a 30. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000014973b42 31. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000001497268d 2025.07.28 11:50:01.616521 [ 6138 ] {} TCPHandler: Code: 47. DB::Exception: Unknown expression or function identifier `x` in scope x = 1. (UNKNOWN_IDENTIFIER), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.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&&) @ 0x000000001404b3b9 4. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3771: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000001401b849 5. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3980: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000014018e31 6. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:2925: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000001402fcbd 7. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3838: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000014019a9e 8. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:209: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000001401270e 9. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000014011fce 10. /build/src/Planner/Utils.cpp:458: DB::buildFilterInfo(std::shared_ptr, std::shared_ptr const&, std::shared_ptr&, std::unordered_set, std::equal_to, std::allocator>) @ 0x0000000013fe8bcf 11. /build/src/Planner/PlannerJoinTree.cpp:535: DB::(anonymous namespace)::buildQueryPlanForTableExpression(std::shared_ptr, std::shared_ptr const&, DB::SelectQueryInfo const&, DB::SelectQueryOptions const&, std::shared_ptr&, bool, bool) @ 0x00000000149956d3 12. /build/src/Planner/PlannerJoinTree.cpp:2252: DB::buildJoinTreeQueryPlan(std::shared_ptr const&, DB::SelectQueryInfo const&, DB::SelectQueryOptions&, std::unordered_set, std::equal_to, std::allocator> const&, std::shared_ptr&) @ 0x000000001498e109 13. /build/src/Planner/Planner.cpp:1553: DB::Planner::buildPlanForQueryNode() @ 0x0000000014979dae 14. /build/src/Planner/Planner.cpp:1308: DB::Planner::buildQueryPlanIfNeeded() @ 0x000000001497685c 15. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:261: DB::InterpreterSelectQueryAnalyzer::extractQueryPlan() && @ 0x000000001497478d 16. /build/src/Interpreters/InterpreterExplainQuery.cpp:509: DB::InterpreterExplainQuery::executeImpl() @ 0x000000001491b92e 17. /build/src/Interpreters/InterpreterExplainQuery.cpp:130: DB::InterpreterExplainQuery::execute() @ 0x0000000014919fc7 18. /build/src/TableFunctions/TableFunctionExplain.cpp:180: DB::(anonymous namespace)::TableFunctionExplain::executeImpl(std::shared_ptr const&, std::shared_ptr, String const&, DB::ColumnsDescription, bool) const @ 0x000000001185d51e 19. /build/src/TableFunctions/ITableFunction.cpp:36: DB::ITableFunction::execute(std::shared_ptr const&, std::shared_ptr, String const&, DB::ColumnsDescription, bool, bool) const @ 0x00000000131e9fc3 20. /build/src/Interpreters/Context.cpp:2501: DB::Context::executeTableFunction(std::shared_ptr const&, std::shared_ptr const&) @ 0x00000000144345b2 21. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:4975: DB::QueryAnalyzer::resolveTableFunction(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&, bool) @ 0x000000001401e9f9 22. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5342: DB::QueryAnalyzer::resolveQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&) @ 0x00000000140452bf 23. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5597: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000140136f0 24. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3870: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x00000000140199de 25. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5334: DB::QueryAnalyzer::resolveQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&) @ 0x00000000140454b0 26. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5597: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000140136f0 27. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000140127f9 28. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000014011fce 29. /build/src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000001406ce8a 30. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000014973b42 31. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000001497268d 2025.07.28 11:50:02.613222 [ 5747 ] {599cc41f-696b-41d6-b28a-d546cc43a64e} executeQuery: Code: 42. DB::Exception: Storage Buffer requires from 9 to 12 parameters: destination_database, destination_table, num_buckets, min_time, max_time, min_rows, max_rows, min_bytes, max_bytes[, flush_time, flush_rows, flush_bytes]. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.6.10636.altinitytest (altinity build)) (from [::1]:53508) (comment: 01817_storage_buffer_parameters.sql) (query 8, line 25) (in query: -- not enough args create table buffer_01817 (key Int) Engine=Buffer(currentDatabase(), data_01817, /* num_layers= */ 1, /* min_time= */ 1, /* max_time= */ 86400, /* min_rows= */ 1e9, /* max_rows= */ 1e6, /* min_bytes= */ 0 /* max_bytes= 4e6 */ );), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000000a074fcb 4. /build/src/Storages/StorageBuffer.cpp:1216: std::shared_ptr std::__function::__policy_invoker (DB::StorageFactory::Arguments const&)>::__call_impl[abi:se190107] (DB::StorageFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::StorageFactory::Arguments const&) @ 0x000000001607daff 5. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000015d81ea2 6. /build/src/Interpreters/InterpreterCreateQuery.cpp:1945: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x00000000149009bb 7. /build/src/Interpreters/InterpreterCreateQuery.cpp:1743: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000148f9aa9 8. /build/src/Interpreters/InterpreterCreateQuery.cpp:2352: DB::InterpreterCreateQuery::execute() @ 0x0000000014905a41 9. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88dc9 10. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 11. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 12. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 13. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 14. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 16. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 17. ? @ 0x00007fbc6213eac3 18. ? @ 0x00007fbc621d0850 2025.07.28 11:50:02.636610 [ 5747 ] {} TCPHandler: Code: 42. DB::Exception: Storage Buffer requires from 9 to 12 parameters: destination_database, destination_table, num_buckets, min_time, max_time, min_rows, max_rows, min_bytes, max_bytes[, flush_time, flush_rows, flush_bytes]. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000000a074fcb 4. /build/src/Storages/StorageBuffer.cpp:1216: std::shared_ptr std::__function::__policy_invoker (DB::StorageFactory::Arguments const&)>::__call_impl[abi:se190107] (DB::StorageFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::StorageFactory::Arguments const&) @ 0x000000001607daff 5. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000015d81ea2 6. /build/src/Interpreters/InterpreterCreateQuery.cpp:1945: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x00000000149009bb 7. /build/src/Interpreters/InterpreterCreateQuery.cpp:1743: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000148f9aa9 8. /build/src/Interpreters/InterpreterCreateQuery.cpp:2352: DB::InterpreterCreateQuery::execute() @ 0x0000000014905a41 9. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88dc9 10. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 11. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 12. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 13. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 14. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 16. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 17. ? @ 0x00007fbc6213eac3 18. ? @ 0x00007fbc621d0850 2025.07.28 11:50:02.754539 [ 5747 ] {71ccc8f8-48f4-4c8b-83f6-8dccdec3327c} executeQuery: Code: 42. DB::Exception: Storage Buffer requires from 9 to 12 parameters: destination_database, destination_table, num_buckets, min_time, max_time, min_rows, max_rows, min_bytes, max_bytes[, flush_time, flush_rows, flush_bytes]. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.6.10636.altinitytest (altinity build)) (from [::1]:53508) (comment: 01817_storage_buffer_parameters.sql) (query 9, line 32) (in query: -- too much args create table buffer_01817 (key Int) Engine=Buffer(currentDatabase(), data_01817, /* num_layers= */ 1, /* min_time= */ 1, /* max_time= */ 86400, /* min_rows= */ 1e9, /* max_rows= */ 1e6, /* min_bytes= */ 0, /* max_bytes= */ 4e6, /* flush_time= */ 86400, /* flush_rows= */ 10, /* flush_bytes= */0, 0 );), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000000a074fcb 4. /build/src/Storages/StorageBuffer.cpp:1216: std::shared_ptr std::__function::__policy_invoker (DB::StorageFactory::Arguments const&)>::__call_impl[abi:se190107] (DB::StorageFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::StorageFactory::Arguments const&) @ 0x000000001607daff 5. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000015d81ea2 6. /build/src/Interpreters/InterpreterCreateQuery.cpp:1945: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x00000000149009bb 7. /build/src/Interpreters/InterpreterCreateQuery.cpp:1743: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000148f9aa9 8. /build/src/Interpreters/InterpreterCreateQuery.cpp:2352: DB::InterpreterCreateQuery::execute() @ 0x0000000014905a41 9. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88dc9 10. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 11. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 12. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 13. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 14. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 16. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 17. ? @ 0x00007fbc6213eac3 18. ? @ 0x00007fbc621d0850 2025.07.28 11:50:02.758467 [ 5747 ] {} TCPHandler: Code: 42. DB::Exception: Storage Buffer requires from 9 to 12 parameters: destination_database, destination_table, num_buckets, min_time, max_time, min_rows, max_rows, min_bytes, max_bytes[, flush_time, flush_rows, flush_bytes]. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000000a074fcb 4. /build/src/Storages/StorageBuffer.cpp:1216: std::shared_ptr std::__function::__policy_invoker (DB::StorageFactory::Arguments const&)>::__call_impl[abi:se190107] (DB::StorageFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::StorageFactory::Arguments const&) @ 0x000000001607daff 5. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000015d81ea2 6. /build/src/Interpreters/InterpreterCreateQuery.cpp:1945: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x00000000149009bb 7. /build/src/Interpreters/InterpreterCreateQuery.cpp:1743: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000148f9aa9 8. /build/src/Interpreters/InterpreterCreateQuery.cpp:2352: DB::InterpreterCreateQuery::execute() @ 0x0000000014905a41 9. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88dc9 10. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 11. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 12. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 13. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 14. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 16. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 17. ? @ 0x00007fbc6213eac3 18. ? @ 0x00007fbc621d0850 2025.07.28 11:50:03.539865 [ 4580 ] {fed7876a-2267-4d6e-b9c8-7cf761c09ade} executeQuery: Code: 219. DB::Exception: New table appeared in database being dropped or detached. Try again. (DATABASE_NOT_EMPTY) (version 25.3.6.10636.altinitytest (altinity build)) (from [::1]:50906) (comment: 00952_input_function.sh) (in query: DROP DATABASE IF EXISTS test_xomsowuq SYNC ), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000000a074fcb 4. /build/src/Interpreters/DatabaseCatalog.cpp:608: DB::DatabaseCatalog::detachDatabase(std::shared_ptr, String const&, bool, bool) @ 0x00000000144f41b9 5. /build/src/Interpreters/InterpreterDropQuery.cpp:482: DB::InterpreterDropQuery::executeToDatabaseImpl(DB::ASTDropQuery const&, std::shared_ptr&, std::vector, DB::UUIDTag>, std::allocator, DB::UUIDTag>>>&) @ 0x00000000149179be 6. /build/src/Interpreters/InterpreterDropQuery.cpp:363: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x0000000014913988 7. /build/src/Interpreters/InterpreterDropQuery.cpp:99: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000014913142 8. /build/src/Interpreters/InterpreterDropQuery.cpp:72: DB::InterpreterDropQuery::execute() @ 0x0000000014912b65 9. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88dc9 10. /build/src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x0000000014c8ca7b 11. /build/src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000001686da12 12. /build/src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x0000000016870807 13. /build/src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x0000000016907e99 14. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 15. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 16. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 17. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 18. ? @ 0x00007fbc6213eac3 19. ? @ 0x00007fbc621d0850 2025.07.28 11:50:03.545151 [ 4580 ] {fed7876a-2267-4d6e-b9c8-7cf761c09ade} 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. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000000a074fcb 4. /build/src/Interpreters/DatabaseCatalog.cpp:608: DB::DatabaseCatalog::detachDatabase(std::shared_ptr, String const&, bool, bool) @ 0x00000000144f41b9 5. /build/src/Interpreters/InterpreterDropQuery.cpp:482: DB::InterpreterDropQuery::executeToDatabaseImpl(DB::ASTDropQuery const&, std::shared_ptr&, std::vector, DB::UUIDTag>, std::allocator, DB::UUIDTag>>>&) @ 0x00000000149179be 6. /build/src/Interpreters/InterpreterDropQuery.cpp:363: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x0000000014913988 7. /build/src/Interpreters/InterpreterDropQuery.cpp:99: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000014913142 8. /build/src/Interpreters/InterpreterDropQuery.cpp:72: DB::InterpreterDropQuery::execute() @ 0x0000000014912b65 9. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88dc9 10. /build/src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x0000000014c8ca7b 11. /build/src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000001686da12 12. /build/src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x0000000016870807 13. /build/src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x0000000016907e99 14. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 15. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 16. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 17. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 18. ? @ 0x00007fbc6213eac3 19. ? @ 0x00007fbc621d0850 (version 25.3.6.10636.altinitytest (altinity build)) 2025.07.28 11:50:03.624002 [ 4526 ] {08c78b6e-de3f-4f07-b2c0-ff0aede50c4c} executeQuery: Code: 42. DB::Exception: The signature of table function file shall be the following: - filename - filename, format - filename, format, structure - filename, format, structure, compression_method . (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.6.10636.altinitytest (altinity build)) (from [::1]:35544) (comment: 00758_array_reverse.sql) (query 14, line 15) (in query: SELECT '[RE7', ( SELECT '\0' ) AS riwwq, ( SELECT reverse([( SELECT bitTestAll(NULL) ) , ( SELECT '\0' ) AS ddfweeuy]) ) AS xuvv, '', ( SELECT * FROM file() ) AS wqgdswyc, ( SELECT * FROM file() );), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000a06a8eb 4. /build/src/TableFunctions/ITableFunctionFileLike.cpp:58: DB::ITableFunctionFileLike::parseArgumentsImpl(absl::lts_20250127::InlinedVector, 7ul, std::allocator>>&, std::shared_ptr const&) @ 0x00000000118263c7 5. /build/src/TableFunctions/ITableFunctionFileLike.cpp:52: DB::ITableFunctionFileLike::parseArguments(std::shared_ptr const&, std::shared_ptr) @ 0x0000000011825dca 6. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:4834: DB::QueryAnalyzer::resolveTableFunction(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&, bool) @ 0x000000001401cb85 7. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5342: DB::QueryAnalyzer::resolveQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&) @ 0x00000000140452bf 8. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5597: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000140136f0 9. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3870: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x00000000140199de 10. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3980: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000014018e31 11. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:4304: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000014042fa7 12. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5605: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000014013749 13. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000140127f9 14. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000014011fce 15. /build/src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000001406ce8a 16. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000014973b42 17. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000001497268d 18. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000014974d24 19. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001492924b 20. /build/src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88641 21. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 22. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 23. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 24. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 25. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 26. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 27. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 28. ? @ 0x00007fbc6213eac3 29. ? @ 0x00007fbc621d0850 2025.07.28 11:50:03.646492 [ 4526 ] {} TCPHandler: Code: 42. DB::Exception: The signature of table function file shall be the following: - filename - filename, format - filename, format, structure - filename, format, structure, compression_method . (NUMBER_OF_ARGUMENTS_DOESNT_MATCH), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000a06a8eb 4. /build/src/TableFunctions/ITableFunctionFileLike.cpp:58: DB::ITableFunctionFileLike::parseArgumentsImpl(absl::lts_20250127::InlinedVector, 7ul, std::allocator>>&, std::shared_ptr const&) @ 0x00000000118263c7 5. /build/src/TableFunctions/ITableFunctionFileLike.cpp:52: DB::ITableFunctionFileLike::parseArguments(std::shared_ptr const&, std::shared_ptr) @ 0x0000000011825dca 6. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:4834: DB::QueryAnalyzer::resolveTableFunction(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&, bool) @ 0x000000001401cb85 7. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5342: DB::QueryAnalyzer::resolveQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&) @ 0x00000000140452bf 8. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5597: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000140136f0 9. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3870: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x00000000140199de 10. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3980: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000014018e31 11. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:4304: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000014042fa7 12. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5605: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000014013749 13. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000140127f9 14. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000014011fce 15. /build/src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000001406ce8a 16. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000014973b42 17. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000001497268d 18. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000014974d24 19. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001492924b 20. /build/src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88641 21. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 22. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 23. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 24. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 25. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 26. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 27. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 28. ? @ 0x00007fbc6213eac3 29. ? @ 0x00007fbc621d0850 2025.07.28 11:50:04.524465 [ 5980 ] {0aaa1495-87ec-421e-b493-ab932d30b099} executeQuery: Code: 69. DB::Exception: Too large parameter(s) for aggregate function 'topKWeighted' (maximum is 16777215). (ARGUMENT_OUT_OF_BOUND) (version 25.3.6.10636.altinitytest (altinity build)) (from [::1]:53670) (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. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x000000000a6a1e2b 4. /build/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*) @ 0x00000000113a23c0 5. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000131e00dd 6. /build/src/AggregateFunctions/AggregateFunctionFactory.cpp:130: DB::AggregateFunctionFactory::get(String const&, DB::NullsAction, std::vector, std::allocator>> const&, DB::Array const&, DB::AggregateFunctionProperties&) const @ 0x00000000131df0ca 7. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3368: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000014032fed 8. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3838: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000014019a9e 9. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3980: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000014018e31 10. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:2925: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000001402fcbd 11. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3838: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000014019a9e 12. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3980: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000014018e31 13. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:4304: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000014042fa7 14. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5605: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000014013749 15. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000140127f9 16. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000014011fce 17. /build/src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000001406ce8a 18. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000014973b42 19. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000001497268d 20. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000014974d24 21. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001492924b 22. /build/src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88641 23. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 24. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 25. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 26. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 27. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 28. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 29. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 30. ? @ 0x00007fbc6213eac3 31. ? @ 0x00007fbc621d0850 2025.07.28 11:50:04.530737 [ 5980 ] {} 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. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x000000000a6a1e2b 4. /build/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*) @ 0x00000000113a23c0 5. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000131e00dd 6. /build/src/AggregateFunctions/AggregateFunctionFactory.cpp:130: DB::AggregateFunctionFactory::get(String const&, DB::NullsAction, std::vector, std::allocator>> const&, DB::Array const&, DB::AggregateFunctionProperties&) const @ 0x00000000131df0ca 7. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3368: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000014032fed 8. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3838: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000014019a9e 9. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3980: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000014018e31 10. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:2925: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000001402fcbd 11. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3838: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000014019a9e 12. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3980: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000014018e31 13. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:4304: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000014042fa7 14. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5605: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000014013749 15. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000140127f9 16. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000014011fce 17. /build/src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000001406ce8a 18. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000014973b42 19. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000001497268d 20. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000014974d24 21. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001492924b 22. /build/src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88641 23. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 24. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 25. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 26. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 27. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 28. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 29. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 30. ? @ 0x00007fbc6213eac3 31. ? @ 0x00007fbc621d0850 2025.07.28 11:50:07.517766 [ 4580 ] {a26d7556-76a7-4338-b4a1-0494cdc00cd4} executeQuery: Code: 452. DB::Exception: Setting allow_experimental_object_type should not be changed. (SETTING_CONSTRAINT_VIOLATION) (version 25.3.6.10636.altinitytest (altinity build)) (from [::1]:53888) (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. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x000000000c25bc4b 4. /build/src/Access/SettingsConstraints.cpp:343: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000138596e3 5. /build/src/Access/SettingsConstraints.cpp:300: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000013858faf 6. /build/src/Access/SettingsConstraints.cpp:194: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges const&, DB::SettingSource) const @ 0x00000000138591b3 7. /build/src/Interpreters/Context.cpp:2722: DB::Context::checkSettingsConstraints(DB::SettingsChanges const&, DB::SettingSource) @ 0x0000000014436509 8. /build/src/Interpreters/InterpreterSetQuery.cpp:28: DB::InterpreterSetQuery::execute() @ 0x00000000149e240a 9. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88dc9 10. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 11. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 12. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 13. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 14. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 16. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 17. ? @ 0x00007fbc6213eac3 18. ? @ 0x00007fbc621d0850 2025.07.28 11:50:07.541141 [ 4580 ] {} 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. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x000000000c25bc4b 4. /build/src/Access/SettingsConstraints.cpp:343: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000138596e3 5. /build/src/Access/SettingsConstraints.cpp:300: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000013858faf 6. /build/src/Access/SettingsConstraints.cpp:194: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges const&, DB::SettingSource) const @ 0x00000000138591b3 7. /build/src/Interpreters/Context.cpp:2722: DB::Context::checkSettingsConstraints(DB::SettingsChanges const&, DB::SettingSource) @ 0x0000000014436509 8. /build/src/Interpreters/InterpreterSetQuery.cpp:28: DB::InterpreterSetQuery::execute() @ 0x00000000149e240a 9. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88dc9 10. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 11. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 12. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 13. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 14. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 16. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 17. ? @ 0x00007fbc6213eac3 18. ? @ 0x00007fbc621d0850 2025.07.28 11:50:08.312697 [ 6138 ] {5863a4ce-7474-4948-81e4-01d570fda7be} executeQuery: Code: 219. DB::Exception: New table appeared in database being dropped or detached. Try again. (DATABASE_NOT_EMPTY) (version 25.3.6.10636.altinitytest (altinity build)) (from [::1]:51092) (comment: 02746_index_analysis_binary_operator_with_null.sql) (in query: DROP DATABASE IF EXISTS test_ghd3ioul SYNC ), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000000a074fcb 4. /build/src/Interpreters/DatabaseCatalog.cpp:608: DB::DatabaseCatalog::detachDatabase(std::shared_ptr, String const&, bool, bool) @ 0x00000000144f41b9 5. /build/src/Interpreters/InterpreterDropQuery.cpp:482: DB::InterpreterDropQuery::executeToDatabaseImpl(DB::ASTDropQuery const&, std::shared_ptr&, std::vector, DB::UUIDTag>, std::allocator, DB::UUIDTag>>>&) @ 0x00000000149179be 6. /build/src/Interpreters/InterpreterDropQuery.cpp:363: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x0000000014913988 7. /build/src/Interpreters/InterpreterDropQuery.cpp:99: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000014913142 8. /build/src/Interpreters/InterpreterDropQuery.cpp:72: DB::InterpreterDropQuery::execute() @ 0x0000000014912b65 9. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88dc9 10. /build/src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x0000000014c8ca7b 11. /build/src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000001686da12 12. /build/src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x0000000016870807 13. /build/src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x0000000016907e99 14. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 15. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 16. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 17. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 18. ? @ 0x00007fbc6213eac3 19. ? @ 0x00007fbc621d0850 2025.07.28 11:50:08.330215 [ 6138 ] {5863a4ce-7474-4948-81e4-01d570fda7be} 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. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000000a074fcb 4. /build/src/Interpreters/DatabaseCatalog.cpp:608: DB::DatabaseCatalog::detachDatabase(std::shared_ptr, String const&, bool, bool) @ 0x00000000144f41b9 5. /build/src/Interpreters/InterpreterDropQuery.cpp:482: DB::InterpreterDropQuery::executeToDatabaseImpl(DB::ASTDropQuery const&, std::shared_ptr&, std::vector, DB::UUIDTag>, std::allocator, DB::UUIDTag>>>&) @ 0x00000000149179be 6. /build/src/Interpreters/InterpreterDropQuery.cpp:363: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x0000000014913988 7. /build/src/Interpreters/InterpreterDropQuery.cpp:99: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000014913142 8. /build/src/Interpreters/InterpreterDropQuery.cpp:72: DB::InterpreterDropQuery::execute() @ 0x0000000014912b65 9. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88dc9 10. /build/src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x0000000014c8ca7b 11. /build/src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000001686da12 12. /build/src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x0000000016870807 13. /build/src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x0000000016907e99 14. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 15. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 16. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 17. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 18. ? @ 0x00007fbc6213eac3 19. ? @ 0x00007fbc621d0850 (version 25.3.6.10636.altinitytest (altinity build)) 2025.07.28 11:50:08.420122 [ 4474 ] {f8cbb468-e26c-4ede-b11f-f1facdf20792} executeQuery: Code: 36. DB::Exception: Table function numbers requires step to be a positive number. (BAD_ARGUMENTS) (version 25.3.6.10636.altinitytest (altinity build)) (from [::1]:53936) (comment: 03037_zero_step_in_numbers_table_function.sql) (query 1, line 1) (in query: select * from numbers(1, 10, 0);), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x000000000a06b56b 4. /build/src/TableFunctions/TableFunctionNumbers.cpp:84: DB::(anonymous namespace)::TableFunctionNumbers::executeImpl(std::shared_ptr const&, std::shared_ptr, String const&, DB::ColumnsDescription, bool) const @ 0x0000000011810500 5. /build/src/TableFunctions/ITableFunction.cpp:36: DB::ITableFunction::execute(std::shared_ptr const&, std::shared_ptr, String const&, DB::ColumnsDescription, bool, bool) const @ 0x00000000131e9fc3 6. /build/src/Interpreters/Context.cpp:2501: DB::Context::executeTableFunction(std::shared_ptr const&, std::shared_ptr const&) @ 0x00000000144345b2 7. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:4975: DB::QueryAnalyzer::resolveTableFunction(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&, bool) @ 0x000000001401e9f9 8. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5342: DB::QueryAnalyzer::resolveQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&) @ 0x00000000140452bf 9. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5597: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000140136f0 10. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000140127f9 11. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000014011fce 12. /build/src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000001406ce8a 13. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000014973b42 14. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000001497268d 15. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000014974d24 16. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001492924b 17. /build/src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88641 18. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 19. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 20. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 21. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 22. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 23. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 24. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 25. ? @ 0x00007fbc6213eac3 26. ? @ 0x00007fbc621d0850 2025.07.28 11:50:08.434975 [ 4474 ] {} TCPHandler: Code: 36. DB::Exception: Table function numbers requires step to be a positive number. (BAD_ARGUMENTS), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x000000000a06b56b 4. /build/src/TableFunctions/TableFunctionNumbers.cpp:84: DB::(anonymous namespace)::TableFunctionNumbers::executeImpl(std::shared_ptr const&, std::shared_ptr, String const&, DB::ColumnsDescription, bool) const @ 0x0000000011810500 5. /build/src/TableFunctions/ITableFunction.cpp:36: DB::ITableFunction::execute(std::shared_ptr const&, std::shared_ptr, String const&, DB::ColumnsDescription, bool, bool) const @ 0x00000000131e9fc3 6. /build/src/Interpreters/Context.cpp:2501: DB::Context::executeTableFunction(std::shared_ptr const&, std::shared_ptr const&) @ 0x00000000144345b2 7. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:4975: DB::QueryAnalyzer::resolveTableFunction(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&, bool) @ 0x000000001401e9f9 8. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5342: DB::QueryAnalyzer::resolveQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&) @ 0x00000000140452bf 9. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5597: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000140136f0 10. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000140127f9 11. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000014011fce 12. /build/src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000001406ce8a 13. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000014973b42 14. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000001497268d 15. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000014974d24 16. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001492924b 17. /build/src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88641 18. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 19. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 20. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 21. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 22. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 23. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 24. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 25. ? @ 0x00007fbc6213eac3 26. ? @ 0x00007fbc621d0850 2025.07.28 11:50:09.302550 [ 5747 ] {b3efd42a-9a81-49de-afbb-2cf34517c3f0} executeQuery: Code: 452. DB::Exception: Setting allow_experimental_object_type should not be changed. (SETTING_CONSTRAINT_VIOLATION) (version 25.3.6.10636.altinitytest (altinity build)) (from [::1]:53982) (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. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x000000000c25bc4b 4. /build/src/Access/SettingsConstraints.cpp:343: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000138596e3 5. /build/src/Access/SettingsConstraints.cpp:300: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000013858faf 6. /build/src/Access/SettingsConstraints.cpp:194: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges const&, DB::SettingSource) const @ 0x00000000138591b3 7. /build/src/Interpreters/Context.cpp:2722: DB::Context::checkSettingsConstraints(DB::SettingsChanges const&, DB::SettingSource) @ 0x0000000014436509 8. /build/src/Interpreters/InterpreterSetQuery.cpp:28: DB::InterpreterSetQuery::execute() @ 0x00000000149e240a 9. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88dc9 10. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 11. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 12. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 13. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 14. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 16. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 17. ? @ 0x00007fbc6213eac3 18. ? @ 0x00007fbc621d0850 2025.07.28 11:50:09.312540 [ 5747 ] {} 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. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x000000000c25bc4b 4. /build/src/Access/SettingsConstraints.cpp:343: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000138596e3 5. /build/src/Access/SettingsConstraints.cpp:300: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000013858faf 6. /build/src/Access/SettingsConstraints.cpp:194: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges const&, DB::SettingSource) const @ 0x00000000138591b3 7. /build/src/Interpreters/Context.cpp:2722: DB::Context::checkSettingsConstraints(DB::SettingsChanges const&, DB::SettingSource) @ 0x0000000014436509 8. /build/src/Interpreters/InterpreterSetQuery.cpp:28: DB::InterpreterSetQuery::execute() @ 0x00000000149e240a 9. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88dc9 10. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 11. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 12. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 13. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 14. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 16. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 17. ? @ 0x00007fbc6213eac3 18. ? @ 0x00007fbc621d0850 2025.07.28 11:50:09.512257 [ 4526 ] {9a02a0bf-4c38-48fe-a6fb-f52e2efcad72} executeQuery: Code: 219. DB::Exception: New table appeared in database being dropped or detached. Try again. (DATABASE_NOT_EMPTY) (version 25.3.6.10636.altinitytest (altinity build)) (from [::1]:51172) (comment: 03132_sqlancer_union_all.sql) (in query: DROP DATABASE IF EXISTS test_9t9x4ath SYNC ), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000000a074fcb 4. /build/src/Interpreters/DatabaseCatalog.cpp:608: DB::DatabaseCatalog::detachDatabase(std::shared_ptr, String const&, bool, bool) @ 0x00000000144f41b9 5. /build/src/Interpreters/InterpreterDropQuery.cpp:482: DB::InterpreterDropQuery::executeToDatabaseImpl(DB::ASTDropQuery const&, std::shared_ptr&, std::vector, DB::UUIDTag>, std::allocator, DB::UUIDTag>>>&) @ 0x00000000149179be 6. /build/src/Interpreters/InterpreterDropQuery.cpp:363: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x0000000014913988 7. /build/src/Interpreters/InterpreterDropQuery.cpp:99: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000014913142 8. /build/src/Interpreters/InterpreterDropQuery.cpp:72: DB::InterpreterDropQuery::execute() @ 0x0000000014912b65 9. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88dc9 10. /build/src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x0000000014c8ca7b 11. /build/src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000001686da12 12. /build/src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x0000000016870807 13. /build/src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x0000000016907e99 14. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 15. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 16. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 17. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 18. ? @ 0x00007fbc6213eac3 19. ? @ 0x00007fbc621d0850 2025.07.28 11:50:09.525104 [ 4526 ] {9a02a0bf-4c38-48fe-a6fb-f52e2efcad72} 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. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000000a074fcb 4. /build/src/Interpreters/DatabaseCatalog.cpp:608: DB::DatabaseCatalog::detachDatabase(std::shared_ptr, String const&, bool, bool) @ 0x00000000144f41b9 5. /build/src/Interpreters/InterpreterDropQuery.cpp:482: DB::InterpreterDropQuery::executeToDatabaseImpl(DB::ASTDropQuery const&, std::shared_ptr&, std::vector, DB::UUIDTag>, std::allocator, DB::UUIDTag>>>&) @ 0x00000000149179be 6. /build/src/Interpreters/InterpreterDropQuery.cpp:363: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x0000000014913988 7. /build/src/Interpreters/InterpreterDropQuery.cpp:99: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000014913142 8. /build/src/Interpreters/InterpreterDropQuery.cpp:72: DB::InterpreterDropQuery::execute() @ 0x0000000014912b65 9. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88dc9 10. /build/src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x0000000014c8ca7b 11. /build/src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000001686da12 12. /build/src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x0000000016870807 13. /build/src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x0000000016907e99 14. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 15. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 16. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 17. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 18. ? @ 0x00007fbc6213eac3 19. ? @ 0x00007fbc621d0850 (version 25.3.6.10636.altinitytest (altinity build)) 2025.07.28 11:50:09.814648 [ 6138 ] {4983156a-9bff-406c-9ed3-c620b7927e77} executeQuery: Code: 47. DB::Exception: Unknown expression or function identifier `x` in scope x = 1. Maybe you meant: ['d']. (UNKNOWN_IDENTIFIER) (version 25.3.6.10636.altinitytest (altinity build)) (from [::ffff:127.0.0.1]:60168) (comment: 02344_distinct_limit_distiributed.sql) (query 14, line 20) (in query: SELECT DISTINCT `__table1`.`id` AS `id` FROM `test_1`.`t_distinct_limit` AS `__table1` LIMIT _CAST(10, 'UInt64')), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.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&&) @ 0x000000001404b3b9 4. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3771: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000001401b849 5. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3980: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000014018e31 6. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:2925: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000001402fcbd 7. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3838: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000014019a9e 8. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:209: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000001401270e 9. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000014011fce 10. /build/src/Planner/Utils.cpp:458: DB::buildFilterInfo(std::shared_ptr, std::shared_ptr const&, std::shared_ptr&, std::unordered_set, std::equal_to, std::allocator>) @ 0x0000000013fe8bcf 11. /build/src/Planner/PlannerJoinTree.cpp:535: DB::(anonymous namespace)::buildQueryPlanForTableExpression(std::shared_ptr, std::shared_ptr const&, DB::SelectQueryInfo const&, DB::SelectQueryOptions const&, std::shared_ptr&, bool, bool) @ 0x00000000149956d3 12. /build/src/Planner/PlannerJoinTree.cpp:2252: DB::buildJoinTreeQueryPlan(std::shared_ptr const&, DB::SelectQueryInfo const&, DB::SelectQueryOptions&, std::unordered_set, std::equal_to, std::allocator> const&, std::shared_ptr&) @ 0x000000001498e109 13. /build/src/Planner/Planner.cpp:1553: DB::Planner::buildPlanForQueryNode() @ 0x0000000014979dae 14. /build/src/Planner/Planner.cpp:1308: DB::Planner::buildQueryPlanIfNeeded() @ 0x000000001497685c 15. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:255: DB::InterpreterSelectQueryAnalyzer::getQueryPlan() @ 0x000000001497476d 16. /build/src/Interpreters/executeQuery.cpp:1405: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88806 17. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 18. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 19. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 20. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 21. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 22. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 23. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 24. ? @ 0x00007fbc6213eac3 25. ? @ 0x00007fbc621d0850 2025.07.28 11:50:09.821048 [ 6138 ] {} TCPHandler: Code: 47. DB::Exception: Unknown expression or function identifier `x` in scope x = 1. Maybe you meant: ['d']. (UNKNOWN_IDENTIFIER), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.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&&) @ 0x000000001404b3b9 4. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3771: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000001401b849 5. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3980: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000014018e31 6. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:2925: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000001402fcbd 7. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3838: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000014019a9e 8. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:209: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000001401270e 9. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000014011fce 10. /build/src/Planner/Utils.cpp:458: DB::buildFilterInfo(std::shared_ptr, std::shared_ptr const&, std::shared_ptr&, std::unordered_set, std::equal_to, std::allocator>) @ 0x0000000013fe8bcf 11. /build/src/Planner/PlannerJoinTree.cpp:535: DB::(anonymous namespace)::buildQueryPlanForTableExpression(std::shared_ptr, std::shared_ptr const&, DB::SelectQueryInfo const&, DB::SelectQueryOptions const&, std::shared_ptr&, bool, bool) @ 0x00000000149956d3 12. /build/src/Planner/PlannerJoinTree.cpp:2252: DB::buildJoinTreeQueryPlan(std::shared_ptr const&, DB::SelectQueryInfo const&, DB::SelectQueryOptions&, std::unordered_set, std::equal_to, std::allocator> const&, std::shared_ptr&) @ 0x000000001498e109 13. /build/src/Planner/Planner.cpp:1553: DB::Planner::buildPlanForQueryNode() @ 0x0000000014979dae 14. /build/src/Planner/Planner.cpp:1308: DB::Planner::buildQueryPlanIfNeeded() @ 0x000000001497685c 15. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:255: DB::InterpreterSelectQueryAnalyzer::getQueryPlan() @ 0x000000001497476d 16. /build/src/Interpreters/executeQuery.cpp:1405: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88806 17. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 18. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 19. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 20. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 21. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 22. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 23. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 24. ? @ 0x00007fbc6213eac3 25. ? @ 0x00007fbc621d0850 2025.07.28 11:50:09.866193 [ 4587 ] {deaba744-c34d-4154-81ba-34d69f0a1b7e} executeQuery: Code: 47. DB::Exception: Unknown expression or function identifier `x` in scope x = 1. Maybe you meant: ['d']. (UNKNOWN_IDENTIFIER) (version 25.3.6.10636.altinitytest (altinity build)) (from [::ffff:127.0.0.1]:45864) (comment: 02344_distinct_limit_distiributed.sql) (query 14, line 20) (in query: SELECT DISTINCT `__table1`.`id` AS `id` FROM `test_1`.`t_distinct_limit` AS `__table1` LIMIT _CAST(10, 'UInt64')), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.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&&) @ 0x000000001404b3b9 4. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3771: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000001401b849 5. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3980: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000014018e31 6. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:2925: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000001402fcbd 7. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3838: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000014019a9e 8. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:209: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000001401270e 9. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000014011fce 10. /build/src/Planner/Utils.cpp:458: DB::buildFilterInfo(std::shared_ptr, std::shared_ptr const&, std::shared_ptr&, std::unordered_set, std::equal_to, std::allocator>) @ 0x0000000013fe8bcf 11. /build/src/Planner/PlannerJoinTree.cpp:535: DB::(anonymous namespace)::buildQueryPlanForTableExpression(std::shared_ptr, std::shared_ptr const&, DB::SelectQueryInfo const&, DB::SelectQueryOptions const&, std::shared_ptr&, bool, bool) @ 0x00000000149956d3 12. /build/src/Planner/PlannerJoinTree.cpp:2252: DB::buildJoinTreeQueryPlan(std::shared_ptr const&, DB::SelectQueryInfo const&, DB::SelectQueryOptions&, std::unordered_set, std::equal_to, std::allocator> const&, std::shared_ptr&) @ 0x000000001498e109 13. /build/src/Planner/Planner.cpp:1553: DB::Planner::buildPlanForQueryNode() @ 0x0000000014979dae 14. /build/src/Planner/Planner.cpp:1308: DB::Planner::buildQueryPlanIfNeeded() @ 0x000000001497685c 15. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:255: DB::InterpreterSelectQueryAnalyzer::getQueryPlan() @ 0x000000001497476d 16. /build/src/Interpreters/executeQuery.cpp:1405: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88806 17. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 18. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 19. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 20. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 21. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 22. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 23. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 24. ? @ 0x00007fbc6213eac3 25. ? @ 0x00007fbc621d0850 2025.07.28 11:50:09.909960 [ 4587 ] {} TCPHandler: Code: 47. DB::Exception: Unknown expression or function identifier `x` in scope x = 1. Maybe you meant: ['d']. (UNKNOWN_IDENTIFIER), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.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&&) @ 0x000000001404b3b9 4. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3771: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000001401b849 5. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3980: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000014018e31 6. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:2925: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000001402fcbd 7. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3838: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000014019a9e 8. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:209: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000001401270e 9. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000014011fce 10. /build/src/Planner/Utils.cpp:458: DB::buildFilterInfo(std::shared_ptr, std::shared_ptr const&, std::shared_ptr&, std::unordered_set, std::equal_to, std::allocator>) @ 0x0000000013fe8bcf 11. /build/src/Planner/PlannerJoinTree.cpp:535: DB::(anonymous namespace)::buildQueryPlanForTableExpression(std::shared_ptr, std::shared_ptr const&, DB::SelectQueryInfo const&, DB::SelectQueryOptions const&, std::shared_ptr&, bool, bool) @ 0x00000000149956d3 12. /build/src/Planner/PlannerJoinTree.cpp:2252: DB::buildJoinTreeQueryPlan(std::shared_ptr const&, DB::SelectQueryInfo const&, DB::SelectQueryOptions&, std::unordered_set, std::equal_to, std::allocator> const&, std::shared_ptr&) @ 0x000000001498e109 13. /build/src/Planner/Planner.cpp:1553: DB::Planner::buildPlanForQueryNode() @ 0x0000000014979dae 14. /build/src/Planner/Planner.cpp:1308: DB::Planner::buildQueryPlanIfNeeded() @ 0x000000001497685c 15. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:255: DB::InterpreterSelectQueryAnalyzer::getQueryPlan() @ 0x000000001497476d 16. /build/src/Interpreters/executeQuery.cpp:1405: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88806 17. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 18. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 19. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 20. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 21. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 22. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 23. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 24. ? @ 0x00007fbc6213eac3 25. ? @ 0x00007fbc621d0850 2025.07.28 11:50:09.934768 [ 4446 ] {9fa7f478-1b43-488e-bbe0-522faf5c9ece} executeQuery: Code: 47. DB::Exception: Received from 127.0.0.2:9000. DB::Exception: Unknown expression or function identifier `x` in scope x = 1. Maybe you meant: ['d']. Stack trace: 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.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&&) @ 0x000000001404b3b9 4. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3771: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000001401b849 5. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3980: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000014018e31 6. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:2925: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000001402fcbd 7. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3838: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000014019a9e 8. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:209: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000001401270e 9. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000014011fce 10. /build/src/Planner/Utils.cpp:458: DB::buildFilterInfo(std::shared_ptr, std::shared_ptr const&, std::shared_ptr&, std::unordered_set, std::equal_to, std::allocator>) @ 0x0000000013fe8bcf 11. /build/src/Planner/PlannerJoinTree.cpp:535: DB::(anonymous namespace)::buildQueryPlanForTableExpression(std::shared_ptr, std::shared_ptr const&, DB::SelectQueryInfo const&, DB::SelectQueryOptions const&, std::shared_ptr&, bool, bool) @ 0x00000000149956d3 12. /build/src/Planner/PlannerJoinTree.cpp:2252: DB::buildJoinTreeQueryPlan(std::shared_ptr const&, DB::SelectQueryInfo const&, DB::SelectQueryOptions&, std::unordered_set, std::equal_to, std::allocator> const&, std::shared_ptr&) @ 0x000000001498e109 13. /build/src/Planner/Planner.cpp:1553: DB::Planner::buildPlanForQueryNode() @ 0x0000000014979dae 14. /build/src/Planner/Planner.cpp:1308: DB::Planner::buildQueryPlanIfNeeded() @ 0x000000001497685c 15. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:255: DB::InterpreterSelectQueryAnalyzer::getQueryPlan() @ 0x000000001497476d 16. /build/src/Interpreters/executeQuery.cpp:1405: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88806 17. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 18. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 19. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 20. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 21. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 22. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 23. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 24. ? @ 0x00007fbc6213eac3 25. ? @ 0x00007fbc621d0850 : While executing Remote. (UNKNOWN_IDENTIFIER) (version 25.3.6.10636.altinitytest (altinity build)) (from [::1]:53512) (comment: 02344_distinct_limit_distiributed.sql) (query 14, line 20) (in query: select id from ( select distinct id from remote('127.0.0.1,127.0.0.2', currentDatabase(),t_distinct_limit) limit 10 ) order by id;), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:111: DB::readException(DB::ReadBuffer&, String const&, bool) @ 0x000000000fc6e157 3. /build/src/Client/Connection.cpp:1445: DB::Connection::receiveException() const @ 0x00000000167d4127 4. /build/src/Client/Connection.cpp:1274: DB::Connection::receivePacket() @ 0x00000000167db312 5. /build/src/Client/PacketReceiver.cpp:66: DB::PacketReceiver::Task::run(std::function, std::function) @ 0x0000000016819393 6. /build/src/Common/AsyncTaskExecutor.cpp:89: DB::AsyncTaskExecutor::Routine::operator()(std::function) @ 0x0000000013bd1892 7. /build/src/Common/Fiber.h:76: boost::context::detail::fiber_record>::run(void*) @ 0x0000000013bd16fa 8. /build/contrib/boost/boost/context/fiber_fcontext.hpp:97: void boost::context::detail::fiber_entry>>(boost::context::detail::transfer_t) @ 0x0000000013bd1621 2025.07.28 11:50:10.052362 [ 4446 ] {} TCPHandler: Code: 47. DB::Exception: Received from 127.0.0.2:9000. DB::Exception: Unknown expression or function identifier `x` in scope x = 1. Maybe you meant: ['d']. Stack trace: 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.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&&) @ 0x000000001404b3b9 4. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3771: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000001401b849 5. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3980: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000014018e31 6. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:2925: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000001402fcbd 7. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3838: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000014019a9e 8. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:209: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000001401270e 9. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000014011fce 10. /build/src/Planner/Utils.cpp:458: DB::buildFilterInfo(std::shared_ptr, std::shared_ptr const&, std::shared_ptr&, std::unordered_set, std::equal_to, std::allocator>) @ 0x0000000013fe8bcf 11. /build/src/Planner/PlannerJoinTree.cpp:535: DB::(anonymous namespace)::buildQueryPlanForTableExpression(std::shared_ptr, std::shared_ptr const&, DB::SelectQueryInfo const&, DB::SelectQueryOptions const&, std::shared_ptr&, bool, bool) @ 0x00000000149956d3 12. /build/src/Planner/PlannerJoinTree.cpp:2252: DB::buildJoinTreeQueryPlan(std::shared_ptr const&, DB::SelectQueryInfo const&, DB::SelectQueryOptions&, std::unordered_set, std::equal_to, std::allocator> const&, std::shared_ptr&) @ 0x000000001498e109 13. /build/src/Planner/Planner.cpp:1553: DB::Planner::buildPlanForQueryNode() @ 0x0000000014979dae 14. /build/src/Planner/Planner.cpp:1308: DB::Planner::buildQueryPlanIfNeeded() @ 0x000000001497685c 15. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:255: DB::InterpreterSelectQueryAnalyzer::getQueryPlan() @ 0x000000001497476d 16. /build/src/Interpreters/executeQuery.cpp:1405: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88806 17. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 18. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 19. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 20. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 21. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 22. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 23. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 24. ? @ 0x00007fbc6213eac3 25. ? @ 0x00007fbc621d0850 : While executing Remote. (UNKNOWN_IDENTIFIER), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:111: DB::readException(DB::ReadBuffer&, String const&, bool) @ 0x000000000fc6e157 3. /build/src/Client/Connection.cpp:1445: DB::Connection::receiveException() const @ 0x00000000167d4127 4. /build/src/Client/Connection.cpp:1274: DB::Connection::receivePacket() @ 0x00000000167db312 5. /build/src/Client/PacketReceiver.cpp:66: DB::PacketReceiver::Task::run(std::function, std::function) @ 0x0000000016819393 6. /build/src/Common/AsyncTaskExecutor.cpp:89: DB::AsyncTaskExecutor::Routine::operator()(std::function) @ 0x0000000013bd1892 7. /build/src/Common/Fiber.h:76: boost::context::detail::fiber_record>::run(void*) @ 0x0000000013bd16fa 8. /build/contrib/boost/boost/context/fiber_fcontext.hpp:97: void boost::context::detail::fiber_entry>>(boost::context::detail::transfer_t) @ 0x0000000013bd1621 Job's origin stack trace: 0. /build/src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000000fc33b84 1. /build/src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000000fcc2ea7 2. /build/src/Common/ThreadPool.cpp:401: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fcc7f1c 3. /build/src/Common/ThreadPool.cpp:494: ThreadPoolImpl>::scheduleOrThrowOnError(std::function, Priority) @ 0x000000000fcc7a0e 4. /build/src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::spawnThreadsImpl() @ 0x00000000169b2c0c 5. /build/src/Processors/Executors/PipelineExecutor.cpp:394: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x00000000169b0ba7 6. /build/src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x00000000169b03f4 7. /build/src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:se190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169bfeab 8. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc3d92 9. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fcca080 10. ? @ 0x00007fbc6213eac3 11. ? @ 0x00007fbc621d0850 Job's origin stack trace: 0. /build/src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000000fc33b84 1. /build/src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000000fcc2ea7 2. /build/src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fcc535c 3. /build/src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000000fcc584d 4. /build/src/Common/ThreadPool.h:279: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x00000000169bf193 5. /build/src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x00000000169bf518 6. /build/src/Server/TCPHandler.cpp:1237: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x00000000168f1525 7. /build/src/Server/TCPHandler.cpp:678: DB::TCPHandler::runImpl() @ 0x00000000168e68e5 8. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 9. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 10. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 11. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 12. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 13. ? @ 0x00007fbc6213eac3 14. ? @ 0x00007fbc621d0850 2025.07.28 11:50:11.000371 [ 4749 ] {ea1b9b7f-a9d8-4a63-b300-e3f3ecb42f95} executeQuery: Code: 57. DB::Exception: Table test_13.sticking_mutations already exists. (TABLE_ALREADY_EXISTS) (version 25.3.6.10636.altinitytest (altinity build)) (from [::1]:54050) (comment: 01415_sticking_mutations.sh) (query 1, line 1) (in query: CREATE TABLE sticking_mutations ( date Date, key UInt64, value1 String, value2 UInt8 ) ENGINE = MergeTree() ORDER BY key;), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000a06a8eb 4. /build/src/Interpreters/InterpreterCreateQuery.cpp:1824: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x0000000014901d53 5. /build/src/Interpreters/InterpreterCreateQuery.cpp:1743: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000148f9aa9 6. /build/src/Interpreters/InterpreterCreateQuery.cpp:2352: DB::InterpreterCreateQuery::execute() @ 0x0000000014905a41 7. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88dc9 8. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 9. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 10. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 11. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 12. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 13. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 14. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 15. ? @ 0x00007fbc6213eac3 16. ? @ 0x00007fbc621d0850 2025.07.28 11:50:11.045601 [ 4749 ] {} TCPHandler: Code: 57. DB::Exception: Table test_13.sticking_mutations already exists. (TABLE_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000a06a8eb 4. /build/src/Interpreters/InterpreterCreateQuery.cpp:1824: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x0000000014901d53 5. /build/src/Interpreters/InterpreterCreateQuery.cpp:1743: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000148f9aa9 6. /build/src/Interpreters/InterpreterCreateQuery.cpp:2352: DB::InterpreterCreateQuery::execute() @ 0x0000000014905a41 7. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88dc9 8. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 9. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 10. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 11. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 12. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 13. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 14. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 15. ? @ 0x00007fbc6213eac3 16. ? @ 0x00007fbc621d0850 2025.07.28 11:50:11.145946 [ 3689 ] {} 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. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000fccaeeb 4. /build/src/Common/ThreadPool.cpp:275: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000fccc813 5. /build/src/Common/ThreadPool.cpp:323: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fcc7bbc 6. /build/src/Common/ThreadPool.cpp:494: ThreadPoolImpl>::scheduleOrThrowOnError(std::function, Priority) @ 0x000000000fcc7a0e 7. /build/src/Common/threadPoolCallbackRunner.h:188: DB::ThreadPoolCallbackRunnerLocal>, std::function>::operator()(std::function&&, Priority, std::optional) @ 0x00000000119df78e 8. /build/src/Interpreters/DatabaseCatalog.cpp:1360: DB::DatabaseCatalog::dropTablesParallel(std::vector, std::allocator>>) @ 0x00000000144fcff9 9. /build/src/Interpreters/DatabaseCatalog.cpp:1382: DB::DatabaseCatalog::dropTableDataTask() @ 0x00000000144fd4fc 10. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000139630d4 11. /build/src/Core/BackgroundSchedulePool.cpp:308: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001396616a 12. /build/src/Core/BackgroundSchedulePool.cpp:171: void std::__function::__policy_invoker::__call_impl[abi:se190107]::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_1>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_1&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001396690a 13. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc3d92 14. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fcca080 15. ? @ 0x00007fbc6213eac3 16. ? @ 0x00007fbc621d0850 (version 25.3.6.10636.altinitytest (altinity build)) 2025.07.28 11:50:11.564248 [ 5980 ] {c6615fa6-0632-4399-b7a3-41662850d18d} 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.6.10636.altinitytest (altinity build)) (from [::1]:54018) (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. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, unsigned long const&, String&&) @ 0x000000000b91d3eb 4. /build/src/Functions/extractAllGroups.h:192: DB::FunctionExtractAllGroups<(anonymous namespace)::HorizontalImpl>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000b91ca4b 5. /build/src/Functions/IFunctionAdaptors.cpp:10: DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000012d995fa 6. /build/src/Functions/IFunction.cpp:353: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d93b52 7. /build/src/Functions/IFunction.cpp:420: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d95059 8. /build/src/Functions/IFunction.cpp:498: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d95c72 9. /build/src/Interpreters/ExpressionActions.cpp:636: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x00000000145176f3 10. /build/src/Processors/Transforms/ExpressionTransform.cpp:25: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x0000000016c0b34c 11. /build/src/Processors/ISimpleTransform.h:33: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000011a9a453 12. /build/src/Processors/ISimpleTransform.cpp:89: DB::ISimpleTransform::work() @ 0x000000001699fca0 13. /build/src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x00000000169bd00f 14. /build/src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x00000000169b2105 15. /build/src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeSingleThread(unsigned long) @ 0x00000000169b23be 16. /build/src/Processors/Executors/PipelineExecutor.cpp:454: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x00000000169b0be7 17. /build/src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x00000000169b03f4 18. /build/src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:se190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169bfeab 19. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc3d92 20. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fcca080 21. ? @ 0x00007fbc6213eac3 22. ? @ 0x00007fbc621d0850 2025.07.28 11:50:11.576974 [ 5980 ] {} 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. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, unsigned long const&, String&&) @ 0x000000000b91d3eb 4. /build/src/Functions/extractAllGroups.h:192: DB::FunctionExtractAllGroups<(anonymous namespace)::HorizontalImpl>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000b91ca4b 5. /build/src/Functions/IFunctionAdaptors.cpp:10: DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000012d995fa 6. /build/src/Functions/IFunction.cpp:353: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d93b52 7. /build/src/Functions/IFunction.cpp:420: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d95059 8. /build/src/Functions/IFunction.cpp:498: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d95c72 9. /build/src/Interpreters/ExpressionActions.cpp:636: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x00000000145176f3 10. /build/src/Processors/Transforms/ExpressionTransform.cpp:25: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x0000000016c0b34c 11. /build/src/Processors/ISimpleTransform.h:33: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000011a9a453 12. /build/src/Processors/ISimpleTransform.cpp:89: DB::ISimpleTransform::work() @ 0x000000001699fca0 13. /build/src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x00000000169bd00f 14. /build/src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x00000000169b2105 15. /build/src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeSingleThread(unsigned long) @ 0x00000000169b23be 16. /build/src/Processors/Executors/PipelineExecutor.cpp:454: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x00000000169b0be7 17. /build/src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x00000000169b03f4 18. /build/src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:se190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169bfeab 19. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc3d92 20. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fcca080 21. ? @ 0x00007fbc6213eac3 22. ? @ 0x00007fbc621d0850 Job's origin stack trace: 0. /build/src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000000fc33b84 1. /build/src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000000fcc2ea7 2. /build/src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fcc535c 3. /build/src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000000fcc584d 4. /build/src/Common/ThreadPool.h:279: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x00000000169bf193 5. /build/src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x00000000169bf518 6. /build/src/Server/TCPHandler.cpp:1237: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x00000000168f1525 7. /build/src/Server/TCPHandler.cpp:678: DB::TCPHandler::runImpl() @ 0x00000000168e68e5 8. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 9. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 10. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 11. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 12. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 13. ? @ 0x00007fbc6213eac3 14. ? @ 0x00007fbc621d0850 2025.07.28 11:50:11.788816 [ 6138 ] {5dc262c1-4d79-4afb-8fa2-0307965f8ab5} executeQuery: Code: 507. DB::Exception: Sharding key is not deterministic. (UNABLE_TO_SKIP_UNUSED_SHARDS) (version 25.3.6.10636.altinitytest (altinity build)) (from [::1]:54012) (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. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000000a074fcb 4. /build/src/Storages/StorageDistributed.cpp:1558: DB::StorageDistributed::getOptimizedCluster(std::shared_ptr, std::shared_ptr const&, DB::SelectQueryInfo const&, std::shared_ptr const&) const @ 0x0000000015d608d8 5. /build/src/Storages/StorageDistributed.cpp:457: DB::StorageDistributed::getQueryProcessingStage(std::shared_ptr, DB::QueryProcessingStage::Enum, std::shared_ptr const&, DB::SelectQueryInfo&) const @ 0x0000000015d5f50d 6. /build/src/Planner/PlannerJoinTree.cpp:921: DB::(anonymous namespace)::buildQueryPlanForTableExpression(std::shared_ptr, std::shared_ptr const&, DB::SelectQueryInfo const&, DB::SelectQueryOptions const&, std::shared_ptr&, bool, bool) @ 0x0000000014996f1b 7. /build/src/Planner/PlannerJoinTree.cpp:2252: DB::buildJoinTreeQueryPlan(std::shared_ptr const&, DB::SelectQueryInfo const&, DB::SelectQueryOptions&, std::unordered_set, std::equal_to, std::allocator> const&, std::shared_ptr&) @ 0x000000001498e109 8. /build/src/Planner/Planner.cpp:1553: DB::Planner::buildPlanForQueryNode() @ 0x0000000014979dae 9. /build/src/Planner/Planner.cpp:1308: DB::Planner::buildQueryPlanIfNeeded() @ 0x000000001497685c 10. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:255: DB::InterpreterSelectQueryAnalyzer::getQueryPlan() @ 0x000000001497476d 11. /build/src/Interpreters/executeQuery.cpp:1405: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88806 12. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 13. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 14. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 15. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 16. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 17. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 18. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 19. ? @ 0x00007fbc6213eac3 20. ? @ 0x00007fbc621d0850 2025.07.28 11:50:11.791733 [ 6138 ] {} 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. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000000a074fcb 4. /build/src/Storages/StorageDistributed.cpp:1558: DB::StorageDistributed::getOptimizedCluster(std::shared_ptr, std::shared_ptr const&, DB::SelectQueryInfo const&, std::shared_ptr const&) const @ 0x0000000015d608d8 5. /build/src/Storages/StorageDistributed.cpp:457: DB::StorageDistributed::getQueryProcessingStage(std::shared_ptr, DB::QueryProcessingStage::Enum, std::shared_ptr const&, DB::SelectQueryInfo&) const @ 0x0000000015d5f50d 6. /build/src/Planner/PlannerJoinTree.cpp:921: DB::(anonymous namespace)::buildQueryPlanForTableExpression(std::shared_ptr, std::shared_ptr const&, DB::SelectQueryInfo const&, DB::SelectQueryOptions const&, std::shared_ptr&, bool, bool) @ 0x0000000014996f1b 7. /build/src/Planner/PlannerJoinTree.cpp:2252: DB::buildJoinTreeQueryPlan(std::shared_ptr const&, DB::SelectQueryInfo const&, DB::SelectQueryOptions&, std::unordered_set, std::equal_to, std::allocator> const&, std::shared_ptr&) @ 0x000000001498e109 8. /build/src/Planner/Planner.cpp:1553: DB::Planner::buildPlanForQueryNode() @ 0x0000000014979dae 9. /build/src/Planner/Planner.cpp:1308: DB::Planner::buildQueryPlanIfNeeded() @ 0x000000001497685c 10. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:255: DB::InterpreterSelectQueryAnalyzer::getQueryPlan() @ 0x000000001497476d 11. /build/src/Interpreters/executeQuery.cpp:1405: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88806 12. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 13. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 14. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 15. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 16. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 17. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 18. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 19. ? @ 0x00007fbc6213eac3 20. ? @ 0x00007fbc621d0850 2025.07.28 11:50:11.849050 [ 4749 ] {d18dd114-a5bb-4502-ad7b-cf2c06f4620c} executeQuery: Code: 42. DB::Exception: Number of arguments for function toDaysSinceYearZero doesn't match: passed 0, should be 1 or 2: In scope SELECT toDaysSinceYearZero(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.6.10636.altinitytest (altinity build)) (from [::1]:59598) (comment: 02874_toDaysSinceYearZero.sql) (query 3, line 4) (in query: SELECT toDaysSinceYearZero();), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, unsigned long&&) @ 0x000000000a06f86b 4. /build/src/Functions/IFunctionDateOrDateTime.h:68: DB::FunctionDateOrDateTimeBase::checkArguments(std::vector> const&, bool) const @ 0x000000000e81e3b6 5. /build/src/Functions/FunctionDateOrDateTimeToSomething.h:23: DB::FunctionDateOrDateTimeToSomething, DB::ToDaysSinceYearZeroImpl>::getReturnTypeImpl(std::vector> const&) const @ 0x000000000e83eea8 6. /build/src/Functions/IFunction.cpp:645: DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x0000000012d96b0c 7. /build/src/Functions/IFunction.cpp:577: DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x0000000012d9669c 8. /build/src/Functions/IFunction.cpp:606: DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x0000000012d96edc 9. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3544: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000014033cc9 10. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3838: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000014019a9e 11. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3980: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000014018e31 12. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:4304: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000014042fa7 13. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5605: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000014013749 14. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000140127f9 15. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000014011fce 16. /build/src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000001406ce8a 17. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000014973b42 18. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000001497268d 19. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000014974d24 20. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001492924b 21. /build/src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88641 22. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 23. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 24. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 25. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 26. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 27. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 28. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 29. ? @ 0x00007fbc6213eac3 30. ? @ 0x00007fbc621d0850 2025.07.28 11:50:11.857564 [ 4749 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function toDaysSinceYearZero doesn't match: passed 0, should be 1 or 2: In scope SELECT toDaysSinceYearZero(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, unsigned long&&) @ 0x000000000a06f86b 4. /build/src/Functions/IFunctionDateOrDateTime.h:68: DB::FunctionDateOrDateTimeBase::checkArguments(std::vector> const&, bool) const @ 0x000000000e81e3b6 5. /build/src/Functions/FunctionDateOrDateTimeToSomething.h:23: DB::FunctionDateOrDateTimeToSomething, DB::ToDaysSinceYearZeroImpl>::getReturnTypeImpl(std::vector> const&) const @ 0x000000000e83eea8 6. /build/src/Functions/IFunction.cpp:645: DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x0000000012d96b0c 7. /build/src/Functions/IFunction.cpp:577: DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x0000000012d9669c 8. /build/src/Functions/IFunction.cpp:606: DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x0000000012d96edc 9. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3544: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000014033cc9 10. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3838: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000014019a9e 11. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3980: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000014018e31 12. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:4304: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000014042fa7 13. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5605: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000014013749 14. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000140127f9 15. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000014011fce 16. /build/src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000001406ce8a 17. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000014973b42 18. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000001497268d 19. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000014974d24 20. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001492924b 21. /build/src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88641 22. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 23. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 24. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 25. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 26. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 27. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 28. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 29. ? @ 0x00007fbc6213eac3 30. ? @ 0x00007fbc621d0850 2025.07.28 11:50:11.998400 [ 4749 ] {df62c60d-5acb-48ee-ae6d-ac913f90e274} executeQuery: Code: 43. DB::Exception: Function toDaysSinceYearZero supports 1 or 2 arguments. The optional 2nd argument must be a constant string with a timezone name: In scope SELECT toDaysSinceYearZero(toDate('2023-09-08'), 3). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.6.10636.altinitytest (altinity build)) (from [::1]:59598) (comment: 02874_toDaysSinceYearZero.sql) (query 4, line 5) (in query: SELECT toDaysSinceYearZero(toDate('2023-09-08'), 3);), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x000000000a06b56b 4. /build/src/Functions/IFunctionDateOrDateTime.h:58: DB::FunctionDateOrDateTimeBase::checkArguments(std::vector> const&, bool) const @ 0x000000000e81e505 5. /build/src/Functions/FunctionDateOrDateTimeToSomething.h:23: DB::FunctionDateOrDateTimeToSomething, DB::ToDaysSinceYearZeroImpl>::getReturnTypeImpl(std::vector> const&) const @ 0x000000000e83eea8 6. /build/src/Functions/IFunction.cpp:645: DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x0000000012d96b0c 7. /build/src/Functions/IFunction.cpp:577: DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x0000000012d9669c 8. /build/src/Functions/IFunction.cpp:606: DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x0000000012d96edc 9. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3544: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000014033cc9 10. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3838: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000014019a9e 11. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3980: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000014018e31 12. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:4304: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000014042fa7 13. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5605: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000014013749 14. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000140127f9 15. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000014011fce 16. /build/src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000001406ce8a 17. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000014973b42 18. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000001497268d 19. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000014974d24 20. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001492924b 21. /build/src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88641 22. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 23. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 24. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 25. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 26. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 27. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 28. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 29. ? @ 0x00007fbc6213eac3 30. ? @ 0x00007fbc621d0850 2025.07.28 11:50:12.019044 [ 4749 ] {} TCPHandler: Code: 43. DB::Exception: Function toDaysSinceYearZero supports 1 or 2 arguments. The optional 2nd argument must be a constant string with a timezone name: In scope SELECT toDaysSinceYearZero(toDate('2023-09-08'), 3). (ILLEGAL_TYPE_OF_ARGUMENT), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x000000000a06b56b 4. /build/src/Functions/IFunctionDateOrDateTime.h:58: DB::FunctionDateOrDateTimeBase::checkArguments(std::vector> const&, bool) const @ 0x000000000e81e505 5. /build/src/Functions/FunctionDateOrDateTimeToSomething.h:23: DB::FunctionDateOrDateTimeToSomething, DB::ToDaysSinceYearZeroImpl>::getReturnTypeImpl(std::vector> const&) const @ 0x000000000e83eea8 6. /build/src/Functions/IFunction.cpp:645: DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x0000000012d96b0c 7. /build/src/Functions/IFunction.cpp:577: DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x0000000012d9669c 8. /build/src/Functions/IFunction.cpp:606: DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x0000000012d96edc 9. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3544: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000014033cc9 10. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3838: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000014019a9e 11. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3980: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000014018e31 12. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:4304: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000014042fa7 13. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5605: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000014013749 14. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000140127f9 15. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000014011fce 16. /build/src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000001406ce8a 17. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000014973b42 18. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000001497268d 19. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000014974d24 20. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001492924b 21. /build/src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88641 22. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 23. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 24. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 25. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 26. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 27. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 28. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 29. ? @ 0x00007fbc6213eac3 30. ? @ 0x00007fbc621d0850 2025.07.28 11:50:12.138935 [ 4749 ] {506ea874-fbdd-4b4b-a45e-7a2b2701dad0} executeQuery: Code: 43. DB::Exception: Illegal type String of argument of function toDaysSinceYearZero. Should be Date, Date32, DateTime or DateTime64: In scope SELECT toDaysSinceYearZero('str'). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.6.10636.altinitytest (altinity build)) (from [::1]:59598) (comment: 02874_toDaysSinceYearZero.sql) (query 5, line 6) (in query: SELECT toDaysSinceYearZero('str');), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000a06a8eb 4. /build/src/Functions/IFunctionDateOrDateTime.h:47: DB::FunctionDateOrDateTimeBase::checkArguments(std::vector> const&, bool) const @ 0x000000000e81e274 5. /build/src/Functions/FunctionDateOrDateTimeToSomething.h:23: DB::FunctionDateOrDateTimeToSomething, DB::ToDaysSinceYearZeroImpl>::getReturnTypeImpl(std::vector> const&) const @ 0x000000000e83eea8 6. /build/src/Functions/IFunction.cpp:645: DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x0000000012d96b0c 7. /build/src/Functions/IFunction.cpp:577: DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x0000000012d9669c 8. /build/src/Functions/IFunction.cpp:606: DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x0000000012d96edc 9. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3544: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000014033cc9 10. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3838: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000014019a9e 11. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3980: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000014018e31 12. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:4304: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000014042fa7 13. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5605: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000014013749 14. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000140127f9 15. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000014011fce 16. /build/src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000001406ce8a 17. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000014973b42 18. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000001497268d 19. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000014974d24 20. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001492924b 21. /build/src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88641 22. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 23. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 24. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 25. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 26. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 27. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 28. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 29. ? @ 0x00007fbc6213eac3 30. ? @ 0x00007fbc621d0850 2025.07.28 11:50:12.153374 [ 4749 ] {} TCPHandler: Code: 43. DB::Exception: Illegal type String of argument of function toDaysSinceYearZero. Should be Date, Date32, DateTime or DateTime64: In scope SELECT toDaysSinceYearZero('str'). (ILLEGAL_TYPE_OF_ARGUMENT), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000a06a8eb 4. /build/src/Functions/IFunctionDateOrDateTime.h:47: DB::FunctionDateOrDateTimeBase::checkArguments(std::vector> const&, bool) const @ 0x000000000e81e274 5. /build/src/Functions/FunctionDateOrDateTimeToSomething.h:23: DB::FunctionDateOrDateTimeToSomething, DB::ToDaysSinceYearZeroImpl>::getReturnTypeImpl(std::vector> const&) const @ 0x000000000e83eea8 6. /build/src/Functions/IFunction.cpp:645: DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x0000000012d96b0c 7. /build/src/Functions/IFunction.cpp:577: DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x0000000012d9669c 8. /build/src/Functions/IFunction.cpp:606: DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x0000000012d96edc 9. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3544: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000014033cc9 10. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3838: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000014019a9e 11. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3980: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000014018e31 12. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:4304: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000014042fa7 13. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5605: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000014013749 14. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000140127f9 15. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000014011fce 16. /build/src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000001406ce8a 17. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000014973b42 18. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000001497268d 19. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000014974d24 20. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001492924b 21. /build/src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88641 22. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 23. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 24. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 25. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 26. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 27. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 28. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 29. ? @ 0x00007fbc6213eac3 30. ? @ 0x00007fbc621d0850 2025.07.28 11:50:12.409161 [ 4749 ] {cde08f3b-7df8-43eb-8925-0b7105a41982} executeQuery: Code: 43. DB::Exception: Illegal type UInt8 of argument of function toDaysSinceYearZero. Should be Date, Date32, DateTime or DateTime64: In scope SELECT toDaysSinceYearZero(42). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.6.10636.altinitytest (altinity build)) (from [::1]:59598) (comment: 02874_toDaysSinceYearZero.sql) (query 6, line 7) (in query: SELECT toDaysSinceYearZero(42);), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000a06a8eb 4. /build/src/Functions/IFunctionDateOrDateTime.h:47: DB::FunctionDateOrDateTimeBase::checkArguments(std::vector> const&, bool) const @ 0x000000000e81e274 5. /build/src/Functions/FunctionDateOrDateTimeToSomething.h:23: DB::FunctionDateOrDateTimeToSomething, DB::ToDaysSinceYearZeroImpl>::getReturnTypeImpl(std::vector> const&) const @ 0x000000000e83eea8 6. /build/src/Functions/IFunction.cpp:645: DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x0000000012d96b0c 7. /build/src/Functions/IFunction.cpp:577: DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x0000000012d9669c 8. /build/src/Functions/IFunction.cpp:606: DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x0000000012d96edc 9. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3544: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000014033cc9 10. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3838: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000014019a9e 11. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3980: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000014018e31 12. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:4304: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000014042fa7 13. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5605: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000014013749 14. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000140127f9 15. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000014011fce 16. /build/src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000001406ce8a 17. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000014973b42 18. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000001497268d 19. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000014974d24 20. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001492924b 21. /build/src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88641 22. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 23. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 24. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 25. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 26. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 27. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 28. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 29. ? @ 0x00007fbc6213eac3 30. ? @ 0x00007fbc621d0850 2025.07.28 11:50:12.420865 [ 4749 ] {} TCPHandler: Code: 43. DB::Exception: Illegal type UInt8 of argument of function toDaysSinceYearZero. Should be Date, Date32, DateTime or DateTime64: In scope SELECT toDaysSinceYearZero(42). (ILLEGAL_TYPE_OF_ARGUMENT), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000a06a8eb 4. /build/src/Functions/IFunctionDateOrDateTime.h:47: DB::FunctionDateOrDateTimeBase::checkArguments(std::vector> const&, bool) const @ 0x000000000e81e274 5. /build/src/Functions/FunctionDateOrDateTimeToSomething.h:23: DB::FunctionDateOrDateTimeToSomething, DB::ToDaysSinceYearZeroImpl>::getReturnTypeImpl(std::vector> const&) const @ 0x000000000e83eea8 6. /build/src/Functions/IFunction.cpp:645: DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x0000000012d96b0c 7. /build/src/Functions/IFunction.cpp:577: DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x0000000012d9669c 8. /build/src/Functions/IFunction.cpp:606: DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x0000000012d96edc 9. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3544: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000014033cc9 10. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3838: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000014019a9e 11. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3980: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000014018e31 12. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:4304: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000014042fa7 13. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5605: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000014013749 14. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000140127f9 15. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000014011fce 16. /build/src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000001406ce8a 17. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000014973b42 18. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000001497268d 19. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000014974d24 20. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001492924b 21. /build/src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88641 22. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 23. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 24. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 25. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 26. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 27. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 28. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 29. ? @ 0x00007fbc6213eac3 30. ? @ 0x00007fbc621d0850 2025.07.28 11:50:14.250597 [ 5747 ] {bbaee32a-52ef-4e81-881f-e5f465c70844} executeQuery: Code: 47. DB::Exception: Unknown expression or function identifier `x` in scope x = 1. Maybe you meant: ['a']. (UNKNOWN_IDENTIFIER) (version 25.3.6.10636.altinitytest (altinity build)) (from [::ffff:127.0.0.1]:53370) (comment: 01258_bom_tsv.sh) (in query: SELECT * FROM bom ORDER BY a ), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.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&&) @ 0x000000001404b3b9 4. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3771: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000001401b849 5. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3980: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000014018e31 6. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:2925: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000001402fcbd 7. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3838: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000014019a9e 8. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:209: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000001401270e 9. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000014011fce 10. /build/src/Planner/Utils.cpp:458: DB::buildFilterInfo(std::shared_ptr, std::shared_ptr const&, std::shared_ptr&, std::unordered_set, std::equal_to, std::allocator>) @ 0x0000000013fe8bcf 11. /build/src/Planner/PlannerJoinTree.cpp:535: DB::(anonymous namespace)::buildQueryPlanForTableExpression(std::shared_ptr, std::shared_ptr const&, DB::SelectQueryInfo const&, DB::SelectQueryOptions const&, std::shared_ptr&, bool, bool) @ 0x00000000149956d3 12. /build/src/Planner/PlannerJoinTree.cpp:2252: DB::buildJoinTreeQueryPlan(std::shared_ptr const&, DB::SelectQueryInfo const&, DB::SelectQueryOptions&, std::unordered_set, std::equal_to, std::allocator> const&, std::shared_ptr&) @ 0x000000001498e109 13. /build/src/Planner/Planner.cpp:1553: DB::Planner::buildPlanForQueryNode() @ 0x0000000014979dae 14. /build/src/Planner/Planner.cpp:1308: DB::Planner::buildQueryPlanIfNeeded() @ 0x000000001497685c 15. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:255: DB::InterpreterSelectQueryAnalyzer::getQueryPlan() @ 0x000000001497476d 16. /build/src/Interpreters/executeQuery.cpp:1405: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88806 17. /build/src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x0000000014c8ca7b 18. /build/src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000001686da12 19. /build/src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x0000000016870807 20. /build/src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x0000000016907e99 21. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 22. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 23. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 24. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 25. ? @ 0x00007fbc6213eac3 26. ? @ 0x00007fbc621d0850 2025.07.28 11:50:14.261127 [ 5747 ] {bbaee32a-52ef-4e81-881f-e5f465c70844} DynamicQueryHandler: Code: 47. DB::Exception: Unknown expression or function identifier `x` in scope x = 1. Maybe you meant: ['a']. (UNKNOWN_IDENTIFIER), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.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&&) @ 0x000000001404b3b9 4. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3771: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000001401b849 5. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3980: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000014018e31 6. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:2925: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000001402fcbd 7. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3838: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000014019a9e 8. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:209: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000001401270e 9. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000014011fce 10. /build/src/Planner/Utils.cpp:458: DB::buildFilterInfo(std::shared_ptr, std::shared_ptr const&, std::shared_ptr&, std::unordered_set, std::equal_to, std::allocator>) @ 0x0000000013fe8bcf 11. /build/src/Planner/PlannerJoinTree.cpp:535: DB::(anonymous namespace)::buildQueryPlanForTableExpression(std::shared_ptr, std::shared_ptr const&, DB::SelectQueryInfo const&, DB::SelectQueryOptions const&, std::shared_ptr&, bool, bool) @ 0x00000000149956d3 12. /build/src/Planner/PlannerJoinTree.cpp:2252: DB::buildJoinTreeQueryPlan(std::shared_ptr const&, DB::SelectQueryInfo const&, DB::SelectQueryOptions&, std::unordered_set, std::equal_to, std::allocator> const&, std::shared_ptr&) @ 0x000000001498e109 13. /build/src/Planner/Planner.cpp:1553: DB::Planner::buildPlanForQueryNode() @ 0x0000000014979dae 14. /build/src/Planner/Planner.cpp:1308: DB::Planner::buildQueryPlanIfNeeded() @ 0x000000001497685c 15. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:255: DB::InterpreterSelectQueryAnalyzer::getQueryPlan() @ 0x000000001497476d 16. /build/src/Interpreters/executeQuery.cpp:1405: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88806 17. /build/src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x0000000014c8ca7b 18. /build/src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000001686da12 19. /build/src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x0000000016870807 20. /build/src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x0000000016907e99 21. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 22. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 23. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 24. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 25. ? @ 0x00007fbc6213eac3 26. ? @ 0x00007fbc621d0850 (version 25.3.6.10636.altinitytest (altinity build)) 2025.07.28 11:50:16.218961 [ 4581 ] {d35c8f94-a179-4c36-b594-f3af1cd4d542} executeQuery: Code: 62. DB::Exception: Invalid qualified name: a. (SYNTAX_ERROR) (version 25.3.6.10636.altinitytest (altinity build)) (from [::1]:59766) (comment: 01372_remote_table_function_empty_table.sql) (query 1, line 1) (in query: SELECT * FROM remote('127..2', 'a.');), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000a9b78ab 4. /build/src/Core/QualifiedTableName.cpp:26: DB::QualifiedTableName::parseFromString(String const&) @ 0x0000000013993d15 5. /build/src/TableFunctions/TableFunctionRemote.cpp:179: DB::TableFunctionRemote::parseArguments(std::shared_ptr const&, std::shared_ptr) @ 0x00000000118033f1 6. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:4834: DB::QueryAnalyzer::resolveTableFunction(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&, bool) @ 0x000000001401cb85 7. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5342: DB::QueryAnalyzer::resolveQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&) @ 0x00000000140452bf 8. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5597: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000140136f0 9. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000140127f9 10. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000014011fce 11. /build/src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000001406ce8a 12. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000014973b42 13. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000001497268d 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000014974d24 15. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001492924b 16. /build/src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88641 17. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 18. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 19. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 20. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 21. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 22. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 23. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 24. ? @ 0x00007fbc6213eac3 25. ? @ 0x00007fbc621d0850 2025.07.28 11:50:16.224236 [ 4581 ] {} TCPHandler: Code: 62. DB::Exception: Invalid qualified name: a. (SYNTAX_ERROR), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000a9b78ab 4. /build/src/Core/QualifiedTableName.cpp:26: DB::QualifiedTableName::parseFromString(String const&) @ 0x0000000013993d15 5. /build/src/TableFunctions/TableFunctionRemote.cpp:179: DB::TableFunctionRemote::parseArguments(std::shared_ptr const&, std::shared_ptr) @ 0x00000000118033f1 6. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:4834: DB::QueryAnalyzer::resolveTableFunction(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&, bool) @ 0x000000001401cb85 7. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5342: DB::QueryAnalyzer::resolveQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&) @ 0x00000000140452bf 8. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5597: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000140136f0 9. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000140127f9 10. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000014011fce 11. /build/src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000001406ce8a 12. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000014973b42 13. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000001497268d 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000014974d24 15. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001492924b 16. /build/src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88641 17. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 18. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 19. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 20. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 21. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 22. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 23. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 24. ? @ 0x00007fbc6213eac3 25. ? @ 0x00007fbc621d0850 2025.07.28 11:50:17.410193 [ 6138 ] {5de797c9-9369-428f-8760-828174c32ebb} executeQuery: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=818, jobs=779). (CANNOT_SCHEDULE_TASK) (version 25.3.6.10636.altinitytest (altinity build)) (from [::1]:59738) (comment: 01855_jit_comparison_constant_result.sql) (query 11, line 16) (in query: SELECT test_table.a FROM test_table ORDER BY (test_table.a == test_table.a) + 1;), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000fccaeeb 4. /build/src/Common/ThreadPool.cpp:275: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000fccacb3 5. /build/src/Common/ThreadPool.cpp:323: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fcc4ffc 6. /build/src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000000fcc584d 7. /build/src/Common/ThreadPool.h:279: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x00000000169bf193 8. /build/src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x00000000169bf518 9. /build/src/Server/TCPHandler.cpp:1237: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x00000000168f1525 10. /build/src/Server/TCPHandler.cpp:678: DB::TCPHandler::runImpl() @ 0x00000000168e68e5 11. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 12. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 13. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 14. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 15. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 16. ? @ 0x00007fbc6213eac3 17. ? @ 0x00007fbc621d0850 2025.07.28 11:50:17.442607 [ 6138 ] {} TCPHandler: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=818, jobs=779). (CANNOT_SCHEDULE_TASK), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000fccaeeb 4. /build/src/Common/ThreadPool.cpp:275: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000fccacb3 5. /build/src/Common/ThreadPool.cpp:323: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fcc4ffc 6. /build/src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000000fcc584d 7. /build/src/Common/ThreadPool.h:279: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x00000000169bf193 8. /build/src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x00000000169bf518 9. /build/src/Server/TCPHandler.cpp:1237: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x00000000168f1525 10. /build/src/Server/TCPHandler.cpp:678: DB::TCPHandler::runImpl() @ 0x00000000168e68e5 11. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 12. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 13. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 14. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 15. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 16. ? @ 0x00007fbc6213eac3 17. ? @ 0x00007fbc621d0850 2025.07.28 11:50:17.582190 [ 4508 ] {b0bd57aa-1677-4258-9ebd-3e4634d5d659} executeQuery: Code: 57. DB::Exception: Table test_13.log already exists. (TABLE_ALREADY_EXISTS) (version 25.3.6.10636.altinitytest (altinity build)) (from [::1]:59764) (comment: 00299_stripe_log_multiple_inserts.sql) (query 11, line 15) (in query: CREATE TABLE log (x UInt8) ENGINE = TinyLog;), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000a06a8eb 4. /build/src/Interpreters/InterpreterCreateQuery.cpp:1824: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x0000000014901d53 5. /build/src/Interpreters/InterpreterCreateQuery.cpp:1743: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000148f9aa9 6. /build/src/Interpreters/InterpreterCreateQuery.cpp:2352: DB::InterpreterCreateQuery::execute() @ 0x0000000014905a41 7. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88dc9 8. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 9. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 10. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 11. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 12. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 13. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 14. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 15. ? @ 0x00007fbc6213eac3 16. ? @ 0x00007fbc621d0850 2025.07.28 11:50:17.620999 [ 4508 ] {} TCPHandler: Code: 57. DB::Exception: Table test_13.log already exists. (TABLE_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000a06a8eb 4. /build/src/Interpreters/InterpreterCreateQuery.cpp:1824: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x0000000014901d53 5. /build/src/Interpreters/InterpreterCreateQuery.cpp:1743: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000148f9aa9 6. /build/src/Interpreters/InterpreterCreateQuery.cpp:2352: DB::InterpreterCreateQuery::execute() @ 0x0000000014905a41 7. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88dc9 8. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 9. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 10. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 11. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 12. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 13. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 14. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 15. ? @ 0x00007fbc6213eac3 16. ? @ 0x00007fbc621d0850 2025.07.28 11:50:18.049540 [ 4581 ] {97b494e4-0ab2-4d8b-957d-f38a062d078b} executeQuery: Code: 47. DB::Exception: Unknown expression or function identifier `x` in scope x = 1. Maybe you meant: ['a']. (UNKNOWN_IDENTIFIER) (version 25.3.6.10636.altinitytest (altinity build)) (from [::1]:59844) (comment: 01346_array_join_mrxotey.sql) (query 4, line 19) (in query: SELECT b FROM test ARRAY JOIN p WHERE b = 1 AND c IN ( SELECT c FROM test );), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.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&&) @ 0x000000001404b3b9 4. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3771: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000001401b849 5. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3980: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000014018e31 6. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:2925: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000001402fcbd 7. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3838: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000014019a9e 8. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:209: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000001401270e 9. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000014011fce 10. /build/src/Planner/Utils.cpp:458: DB::buildFilterInfo(std::shared_ptr, std::shared_ptr const&, std::shared_ptr&, std::unordered_set, std::equal_to, std::allocator>) @ 0x0000000013fe8bcf 11. /build/src/Planner/PlannerJoinTree.cpp:535: DB::(anonymous namespace)::buildQueryPlanForTableExpression(std::shared_ptr, std::shared_ptr const&, DB::SelectQueryInfo const&, DB::SelectQueryOptions const&, std::shared_ptr&, bool, bool) @ 0x00000000149956d3 12. /build/src/Planner/PlannerJoinTree.cpp:2252: DB::buildJoinTreeQueryPlan(std::shared_ptr const&, DB::SelectQueryInfo const&, DB::SelectQueryOptions&, std::unordered_set, std::equal_to, std::allocator> const&, std::shared_ptr&) @ 0x000000001498e109 13. /build/src/Planner/Planner.cpp:1553: DB::Planner::buildPlanForQueryNode() @ 0x0000000014979dae 14. /build/src/Planner/Planner.cpp:1308: DB::Planner::buildQueryPlanIfNeeded() @ 0x000000001497685c 15. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:255: DB::InterpreterSelectQueryAnalyzer::getQueryPlan() @ 0x000000001497476d 16. /build/src/Interpreters/executeQuery.cpp:1405: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88806 17. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 18. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 19. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 20. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 21. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 22. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 23. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 24. ? @ 0x00007fbc6213eac3 25. ? @ 0x00007fbc621d0850 2025.07.28 11:50:18.075904 [ 4581 ] {} TCPHandler: Code: 47. DB::Exception: Unknown expression or function identifier `x` in scope x = 1. Maybe you meant: ['a']. (UNKNOWN_IDENTIFIER), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.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&&) @ 0x000000001404b3b9 4. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3771: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000001401b849 5. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3980: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000014018e31 6. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:2925: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000001402fcbd 7. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3838: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000014019a9e 8. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:209: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000001401270e 9. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000014011fce 10. /build/src/Planner/Utils.cpp:458: DB::buildFilterInfo(std::shared_ptr, std::shared_ptr const&, std::shared_ptr&, std::unordered_set, std::equal_to, std::allocator>) @ 0x0000000013fe8bcf 11. /build/src/Planner/PlannerJoinTree.cpp:535: DB::(anonymous namespace)::buildQueryPlanForTableExpression(std::shared_ptr, std::shared_ptr const&, DB::SelectQueryInfo const&, DB::SelectQueryOptions const&, std::shared_ptr&, bool, bool) @ 0x00000000149956d3 12. /build/src/Planner/PlannerJoinTree.cpp:2252: DB::buildJoinTreeQueryPlan(std::shared_ptr const&, DB::SelectQueryInfo const&, DB::SelectQueryOptions&, std::unordered_set, std::equal_to, std::allocator> const&, std::shared_ptr&) @ 0x000000001498e109 13. /build/src/Planner/Planner.cpp:1553: DB::Planner::buildPlanForQueryNode() @ 0x0000000014979dae 14. /build/src/Planner/Planner.cpp:1308: DB::Planner::buildQueryPlanIfNeeded() @ 0x000000001497685c 15. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:255: DB::InterpreterSelectQueryAnalyzer::getQueryPlan() @ 0x000000001497476d 16. /build/src/Interpreters/executeQuery.cpp:1405: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88806 17. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 18. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 19. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 20. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 21. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 22. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 23. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 24. ? @ 0x00007fbc6213eac3 25. ? @ 0x00007fbc621d0850 2025.07.28 11:50:18.720252 [ 4587 ] {a4b0c8e0-9ba6-4b74-aa4f-cd1462a8d1c4} executeQuery: Code: 1. DB::Exception: Expected function, got: x. (UNSUPPORTED_METHOD) (version 25.3.6.10636.altinitytest (altinity build)) (from [::1]:59936) (comment: 02292_create_function_validate.sql) (query 1, line 1) (in query: create function foo as x -- { serverError UNSUPPORTED_METHOD } ), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x000000000a06b56b 4. /build/src/Functions/UserDefined/UserDefinedSQLFunctionFactory.cpp:55: DB::UserDefinedSQLFunctionFactory::checkCanBeRegistered(std::shared_ptr const&, String const&, DB::IAST const&) @ 0x0000000016eef6b3 5. /build/src/Functions/UserDefined/UserDefinedSQLFunctionFactory.cpp:135: DB::UserDefinedSQLFunctionFactory::registerFunction(std::shared_ptr const&, String const&, std::shared_ptr, bool, bool) @ 0x0000000016eefaa8 6. /build/src/Interpreters/InterpreterCreateFunctionQuery.cpp:52: DB::InterpreterCreateFunctionQuery::execute() @ 0x0000000014cf82df 7. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88dc9 8. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 9. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 10. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 11. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 12. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 13. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 14. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 15. ? @ 0x00007fbc6213eac3 16. ? @ 0x00007fbc621d0850 2025.07.28 11:50:18.735805 [ 4587 ] {} TCPHandler: Code: 1. DB::Exception: Expected function, got: x. (UNSUPPORTED_METHOD), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x000000000a06b56b 4. /build/src/Functions/UserDefined/UserDefinedSQLFunctionFactory.cpp:55: DB::UserDefinedSQLFunctionFactory::checkCanBeRegistered(std::shared_ptr const&, String const&, DB::IAST const&) @ 0x0000000016eef6b3 5. /build/src/Functions/UserDefined/UserDefinedSQLFunctionFactory.cpp:135: DB::UserDefinedSQLFunctionFactory::registerFunction(std::shared_ptr const&, String const&, std::shared_ptr, bool, bool) @ 0x0000000016eefaa8 6. /build/src/Interpreters/InterpreterCreateFunctionQuery.cpp:52: DB::InterpreterCreateFunctionQuery::execute() @ 0x0000000014cf82df 7. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88dc9 8. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 9. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 10. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 11. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 12. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 13. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 14. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 15. ? @ 0x00007fbc6213eac3 16. ? @ 0x00007fbc621d0850 2025.07.28 11:50:18.942514 [ 7630 ] {4349fe6d-373a-41f0-ae2f-e73fca684702} 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.6.10636.altinitytest (altinity build)) (from [::1]:59958) (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. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x000000000a080b2b 4. /build/src/IO/ReadHelpers.cpp:95: DB::throwAtAssertionFailed(char const*, DB::ReadBuffer&) @ 0x000000000fc6bcc9 5. /build/src/IO/ReadHelpers.h:204: DB::TabSeparatedFormatReader::skipFieldDelimiter() @ 0x0000000016bba3c2 6. /build/src/Processors/Formats/RowInputFormatWithNamesAndTypes.cpp:299: DB::RowInputFormatWithNamesAndTypes::readRow(std::vector::mutable_ptr, std::allocator::mutable_ptr>>&, DB::RowReadExtension&) @ 0x0000000016a47a5a 7. /build/src/Processors/Formats/IRowInputFormat.cpp:143: DB::IRowInputFormat::read() @ 0x0000000016a1fc72 8. /build/src/Processors/Formats/IInputFormat.cpp:19: DB::IInputFormat::generate() @ 0x00000000169c5536 9. /build/src/Processors/ISource.cpp:139: DB::ISource::tryGenerate() @ 0x00000000169a24fa 10. /build/src/Processors/ISource.cpp:108: DB::ISource::work() @ 0x00000000169a21e7 11. /build/src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x00000000169bd00f 12. /build/src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x00000000169b2105 13. /build/src/Processors/Executors/PipelineExecutor.cpp:170: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x00000000169b16a7 14. /build/src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x00000000169c081c 15. /build/src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x00000000169c0978 16. /build/src/TableFunctions/TableFunctionFormat.cpp:125: DB::(anonymous namespace)::TableFunctionFormat::executeImpl(std::shared_ptr const&, std::shared_ptr, String const&, DB::ColumnsDescription, bool) const @ 0x0000000011859cbf 17. /build/src/TableFunctions/ITableFunction.cpp:36: DB::ITableFunction::execute(std::shared_ptr const&, std::shared_ptr, String const&, DB::ColumnsDescription, bool, bool) const @ 0x00000000131e9fc3 18. /build/src/Interpreters/Context.cpp:2501: DB::Context::executeTableFunction(std::shared_ptr const&, std::shared_ptr const&) @ 0x00000000144345b2 19. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:4975: DB::QueryAnalyzer::resolveTableFunction(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&, bool) @ 0x000000001401e9f9 20. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5342: DB::QueryAnalyzer::resolveQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&) @ 0x00000000140452bf 21. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5597: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000140136f0 22. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000140127f9 23. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000014011fce 24. /build/src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000001406ce8a 25. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000014973b42 26. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000001497268d 27. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000014974d24 28. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001492924b 29. /build/src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88641 30. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 31. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 2025.07.28 11:50:18.947032 [ 7630 ] {} 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. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x000000000a080b2b 4. /build/src/IO/ReadHelpers.cpp:95: DB::throwAtAssertionFailed(char const*, DB::ReadBuffer&) @ 0x000000000fc6bcc9 5. /build/src/IO/ReadHelpers.h:204: DB::TabSeparatedFormatReader::skipFieldDelimiter() @ 0x0000000016bba3c2 6. /build/src/Processors/Formats/RowInputFormatWithNamesAndTypes.cpp:299: DB::RowInputFormatWithNamesAndTypes::readRow(std::vector::mutable_ptr, std::allocator::mutable_ptr>>&, DB::RowReadExtension&) @ 0x0000000016a47a5a 7. /build/src/Processors/Formats/IRowInputFormat.cpp:143: DB::IRowInputFormat::read() @ 0x0000000016a1fc72 8. /build/src/Processors/Formats/IInputFormat.cpp:19: DB::IInputFormat::generate() @ 0x00000000169c5536 9. /build/src/Processors/ISource.cpp:139: DB::ISource::tryGenerate() @ 0x00000000169a24fa 10. /build/src/Processors/ISource.cpp:108: DB::ISource::work() @ 0x00000000169a21e7 11. /build/src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x00000000169bd00f 12. /build/src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x00000000169b2105 13. /build/src/Processors/Executors/PipelineExecutor.cpp:170: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x00000000169b16a7 14. /build/src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x00000000169c081c 15. /build/src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x00000000169c0978 16. /build/src/TableFunctions/TableFunctionFormat.cpp:125: DB::(anonymous namespace)::TableFunctionFormat::executeImpl(std::shared_ptr const&, std::shared_ptr, String const&, DB::ColumnsDescription, bool) const @ 0x0000000011859cbf 17. /build/src/TableFunctions/ITableFunction.cpp:36: DB::ITableFunction::execute(std::shared_ptr const&, std::shared_ptr, String const&, DB::ColumnsDescription, bool, bool) const @ 0x00000000131e9fc3 18. /build/src/Interpreters/Context.cpp:2501: DB::Context::executeTableFunction(std::shared_ptr const&, std::shared_ptr const&) @ 0x00000000144345b2 19. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:4975: DB::QueryAnalyzer::resolveTableFunction(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&, bool) @ 0x000000001401e9f9 20. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5342: DB::QueryAnalyzer::resolveQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&) @ 0x00000000140452bf 21. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5597: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000140136f0 22. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000140127f9 23. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000014011fce 24. /build/src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000001406ce8a 25. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000014973b42 26. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000001497268d 27. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000014974d24 28. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001492924b 29. /build/src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88641 30. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 31. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 2025.07.28 11:50:19.211002 [ 7630 ] {50328093-02f4-46be-a29a-f6ab3182a0bd} 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.6.10636.altinitytest (altinity build)) (from [::1]:59958) (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. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x000000000a080b2b 4. /build/src/IO/ReadHelpers.cpp:95: DB::throwAtAssertionFailed(char const*, DB::ReadBuffer&) @ 0x000000000fc6bcc9 5. /build/src/IO/ReadHelpers.h:204: DB::TabSeparatedFormatReader::skipFieldDelimiter() @ 0x0000000016bba3c2 6. /build/src/Processors/Formats/RowInputFormatWithNamesAndTypes.cpp:299: DB::RowInputFormatWithNamesAndTypes::readRow(std::vector::mutable_ptr, std::allocator::mutable_ptr>>&, DB::RowReadExtension&) @ 0x0000000016a47a5a 7. /build/src/Processors/Formats/IRowInputFormat.cpp:143: DB::IRowInputFormat::read() @ 0x0000000016a1fc72 8. /build/src/Processors/Formats/IInputFormat.cpp:19: DB::IInputFormat::generate() @ 0x00000000169c5536 9. /build/src/Processors/ISource.cpp:139: DB::ISource::tryGenerate() @ 0x00000000169a24fa 10. /build/src/Processors/ISource.cpp:108: DB::ISource::work() @ 0x00000000169a21e7 11. /build/src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x00000000169bd00f 12. /build/src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x00000000169b2105 13. /build/src/Processors/Executors/PipelineExecutor.cpp:170: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x00000000169b16a7 14. /build/src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x00000000169c081c 15. /build/src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x00000000169c0978 16. /build/src/TableFunctions/TableFunctionFormat.cpp:125: DB::(anonymous namespace)::TableFunctionFormat::executeImpl(std::shared_ptr const&, std::shared_ptr, String const&, DB::ColumnsDescription, bool) const @ 0x0000000011859cbf 17. /build/src/TableFunctions/ITableFunction.cpp:36: DB::ITableFunction::execute(std::shared_ptr const&, std::shared_ptr, String const&, DB::ColumnsDescription, bool, bool) const @ 0x00000000131e9fc3 18. /build/src/Interpreters/Context.cpp:2501: DB::Context::executeTableFunction(std::shared_ptr const&, std::shared_ptr const&) @ 0x00000000144345b2 19. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:4975: DB::QueryAnalyzer::resolveTableFunction(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&, bool) @ 0x000000001401e9f9 20. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5342: DB::QueryAnalyzer::resolveQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&) @ 0x00000000140452bf 21. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5597: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000140136f0 22. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000140127f9 23. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000014011fce 24. /build/src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000001406ce8a 25. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000014973b42 26. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000001497268d 27. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000014974d24 28. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001492924b 29. /build/src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88641 30. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 31. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 2025.07.28 11:50:19.245262 [ 7630 ] {} 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. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x000000000a080b2b 4. /build/src/IO/ReadHelpers.cpp:95: DB::throwAtAssertionFailed(char const*, DB::ReadBuffer&) @ 0x000000000fc6bcc9 5. /build/src/IO/ReadHelpers.h:204: DB::TabSeparatedFormatReader::skipFieldDelimiter() @ 0x0000000016bba3c2 6. /build/src/Processors/Formats/RowInputFormatWithNamesAndTypes.cpp:299: DB::RowInputFormatWithNamesAndTypes::readRow(std::vector::mutable_ptr, std::allocator::mutable_ptr>>&, DB::RowReadExtension&) @ 0x0000000016a47a5a 7. /build/src/Processors/Formats/IRowInputFormat.cpp:143: DB::IRowInputFormat::read() @ 0x0000000016a1fc72 8. /build/src/Processors/Formats/IInputFormat.cpp:19: DB::IInputFormat::generate() @ 0x00000000169c5536 9. /build/src/Processors/ISource.cpp:139: DB::ISource::tryGenerate() @ 0x00000000169a24fa 10. /build/src/Processors/ISource.cpp:108: DB::ISource::work() @ 0x00000000169a21e7 11. /build/src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x00000000169bd00f 12. /build/src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x00000000169b2105 13. /build/src/Processors/Executors/PipelineExecutor.cpp:170: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x00000000169b16a7 14. /build/src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x00000000169c081c 15. /build/src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x00000000169c0978 16. /build/src/TableFunctions/TableFunctionFormat.cpp:125: DB::(anonymous namespace)::TableFunctionFormat::executeImpl(std::shared_ptr const&, std::shared_ptr, String const&, DB::ColumnsDescription, bool) const @ 0x0000000011859cbf 17. /build/src/TableFunctions/ITableFunction.cpp:36: DB::ITableFunction::execute(std::shared_ptr const&, std::shared_ptr, String const&, DB::ColumnsDescription, bool, bool) const @ 0x00000000131e9fc3 18. /build/src/Interpreters/Context.cpp:2501: DB::Context::executeTableFunction(std::shared_ptr const&, std::shared_ptr const&) @ 0x00000000144345b2 19. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:4975: DB::QueryAnalyzer::resolveTableFunction(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&, bool) @ 0x000000001401e9f9 20. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5342: DB::QueryAnalyzer::resolveQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&) @ 0x00000000140452bf 21. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5597: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000140136f0 22. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000140127f9 23. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000014011fce 24. /build/src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000001406ce8a 25. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000014973b42 26. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000001497268d 27. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000014974d24 28. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001492924b 29. /build/src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88641 30. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 31. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 2025.07.28 11:50:19.310199 [ 4749 ] {e27afd0e-d53b-418e-b0e8-82b29f17d078} executeQuery: Code: 47. DB::Exception: Missing columns: 'x' while processing: 'SELECT x = 1, id FROM test_1.tab', required columns: 'id' 'x', maybe you meant: 'id': While applying a row policy (see system.row_policies). (UNKNOWN_IDENTIFIER) (version 25.3.6.10636.altinitytest (altinity build)) (from [::1]:59904) (comment: 02346_fulltext_index_bug47393.sql) (query 6, line 18) (in query: -- update column synchronously ALTER TABLE tab UPDATE str = 'I am not inverted' WHERE 1 SETTINGS mutations_sync=1;), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Interpreters/TreeRewriter.cpp:1303: DB::TreeRewriterResult::collectUsedColumns(std::shared_ptr const&, bool, bool) @ 0x0000000014c01fc8 4. /build/src/Interpreters/TreeRewriter.cpp:1448: DB::TreeRewriter::analyzeSelect(std::shared_ptr&, DB::TreeRewriterResult&&, DB::SelectQueryOptions const&, std::vector> const&, std::vector> const&, std::shared_ptr) const @ 0x0000000014c05792 5. /build/src/Interpreters/InterpreterSelectQuery.cpp:272: DB::generateFilterActions(DB::StorageID const&, std::shared_ptr const&, std::shared_ptr const&, std::shared_ptr const&, std::shared_ptr const&, std::shared_ptr const&, std::vector>&, std::shared_ptr) @ 0x000000001493f7f3 6. /build/src/Interpreters/InterpreterSelectQuery.cpp:888: 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 @ 0x0000000014948aa5 7. /build/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) @ 0x0000000014943f47 8. /build/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) @ 0x000000001494088c 9. /build/src/Interpreters/InterpreterSelectQuery.cpp:328: DB::InterpreterSelectQuery::InterpreterSelectQuery(std::shared_ptr const&, std::shared_ptr const&, std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000014946974 10. /build/src/Interpreters/MutationsInterpreter.cpp:1441: DB::MutationsInterpreter::validate() @ 0x0000000014a3191c 11. /build/src/Interpreters/InterpreterAlterQuery.cpp:235: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x00000000148deddb 12. /build/src/Interpreters/InterpreterAlterQuery.cpp:77: DB::InterpreterAlterQuery::execute() @ 0x00000000148dcb0d 13. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88dc9 14. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 15. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 16. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 17. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 18. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 19. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 20. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 21. ? @ 0x00007fbc6213eac3 22. ? @ 0x00007fbc621d0850 2025.07.28 11:50:19.337256 [ 4749 ] {} TCPHandler: Code: 47. DB::Exception: Missing columns: 'x' while processing: 'SELECT x = 1, id FROM test_1.tab', required columns: 'id' 'x', maybe you meant: 'id': While applying a row policy (see system.row_policies). (UNKNOWN_IDENTIFIER), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Interpreters/TreeRewriter.cpp:1303: DB::TreeRewriterResult::collectUsedColumns(std::shared_ptr const&, bool, bool) @ 0x0000000014c01fc8 4. /build/src/Interpreters/TreeRewriter.cpp:1448: DB::TreeRewriter::analyzeSelect(std::shared_ptr&, DB::TreeRewriterResult&&, DB::SelectQueryOptions const&, std::vector> const&, std::vector> const&, std::shared_ptr) const @ 0x0000000014c05792 5. /build/src/Interpreters/InterpreterSelectQuery.cpp:272: DB::generateFilterActions(DB::StorageID const&, std::shared_ptr const&, std::shared_ptr const&, std::shared_ptr const&, std::shared_ptr const&, std::shared_ptr const&, std::vector>&, std::shared_ptr) @ 0x000000001493f7f3 6. /build/src/Interpreters/InterpreterSelectQuery.cpp:888: 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 @ 0x0000000014948aa5 7. /build/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) @ 0x0000000014943f47 8. /build/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) @ 0x000000001494088c 9. /build/src/Interpreters/InterpreterSelectQuery.cpp:328: DB::InterpreterSelectQuery::InterpreterSelectQuery(std::shared_ptr const&, std::shared_ptr const&, std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000014946974 10. /build/src/Interpreters/MutationsInterpreter.cpp:1441: DB::MutationsInterpreter::validate() @ 0x0000000014a3191c 11. /build/src/Interpreters/InterpreterAlterQuery.cpp:235: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x00000000148deddb 12. /build/src/Interpreters/InterpreterAlterQuery.cpp:77: DB::InterpreterAlterQuery::execute() @ 0x00000000148dcb0d 13. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88dc9 14. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 15. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 16. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 17. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 18. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 19. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 20. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 21. ? @ 0x00007fbc6213eac3 22. ? @ 0x00007fbc621d0850 2025.07.28 11:50:19.391712 [ 7630 ] {4ff48534-b35c-488a-a35e-47988a0d4315} 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.6.10636.altinitytest (altinity build)) (from [::1]:59958) (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. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x000000000a080b2b 4. /build/src/IO/ReadHelpers.cpp:95: DB::throwAtAssertionFailed(char const*, DB::ReadBuffer&) @ 0x000000000fc6bcc9 5. /build/src/IO/ReadHelpers.h:204: DB::CSVFormatReader::skipFieldDelimiter() @ 0x0000000016a79787 6. /build/src/Processors/Formats/RowInputFormatWithNamesAndTypes.cpp:299: DB::RowInputFormatWithNamesAndTypes::readRow(std::vector::mutable_ptr, std::allocator::mutable_ptr>>&, DB::RowReadExtension&) @ 0x0000000016a4ab1e 7. /build/src/Processors/Formats/IRowInputFormat.cpp:143: DB::IRowInputFormat::read() @ 0x0000000016a1fc72 8. /build/src/Processors/Formats/IInputFormat.cpp:19: DB::IInputFormat::generate() @ 0x00000000169c5536 9. /build/src/Processors/ISource.cpp:139: DB::ISource::tryGenerate() @ 0x00000000169a24fa 10. /build/src/Processors/ISource.cpp:108: DB::ISource::work() @ 0x00000000169a21e7 11. /build/src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x00000000169bd00f 12. /build/src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x00000000169b2105 13. /build/src/Processors/Executors/PipelineExecutor.cpp:170: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x00000000169b16a7 14. /build/src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x00000000169c081c 15. /build/src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x00000000169c0978 16. /build/src/TableFunctions/TableFunctionFormat.cpp:125: DB::(anonymous namespace)::TableFunctionFormat::executeImpl(std::shared_ptr const&, std::shared_ptr, String const&, DB::ColumnsDescription, bool) const @ 0x0000000011859cbf 17. /build/src/TableFunctions/ITableFunction.cpp:36: DB::ITableFunction::execute(std::shared_ptr const&, std::shared_ptr, String const&, DB::ColumnsDescription, bool, bool) const @ 0x00000000131e9fc3 18. /build/src/Interpreters/Context.cpp:2501: DB::Context::executeTableFunction(std::shared_ptr const&, std::shared_ptr const&) @ 0x00000000144345b2 19. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:4975: DB::QueryAnalyzer::resolveTableFunction(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&, bool) @ 0x000000001401e9f9 20. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5342: DB::QueryAnalyzer::resolveQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&) @ 0x00000000140452bf 21. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5597: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000140136f0 22. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000140127f9 23. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000014011fce 24. /build/src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000001406ce8a 25. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000014973b42 26. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000001497268d 27. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000014974d24 28. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001492924b 29. /build/src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88641 30. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 31. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 2025.07.28 11:50:19.414718 [ 7630 ] {} 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. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x000000000a080b2b 4. /build/src/IO/ReadHelpers.cpp:95: DB::throwAtAssertionFailed(char const*, DB::ReadBuffer&) @ 0x000000000fc6bcc9 5. /build/src/IO/ReadHelpers.h:204: DB::CSVFormatReader::skipFieldDelimiter() @ 0x0000000016a79787 6. /build/src/Processors/Formats/RowInputFormatWithNamesAndTypes.cpp:299: DB::RowInputFormatWithNamesAndTypes::readRow(std::vector::mutable_ptr, std::allocator::mutable_ptr>>&, DB::RowReadExtension&) @ 0x0000000016a4ab1e 7. /build/src/Processors/Formats/IRowInputFormat.cpp:143: DB::IRowInputFormat::read() @ 0x0000000016a1fc72 8. /build/src/Processors/Formats/IInputFormat.cpp:19: DB::IInputFormat::generate() @ 0x00000000169c5536 9. /build/src/Processors/ISource.cpp:139: DB::ISource::tryGenerate() @ 0x00000000169a24fa 10. /build/src/Processors/ISource.cpp:108: DB::ISource::work() @ 0x00000000169a21e7 11. /build/src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x00000000169bd00f 12. /build/src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x00000000169b2105 13. /build/src/Processors/Executors/PipelineExecutor.cpp:170: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x00000000169b16a7 14. /build/src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x00000000169c081c 15. /build/src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x00000000169c0978 16. /build/src/TableFunctions/TableFunctionFormat.cpp:125: DB::(anonymous namespace)::TableFunctionFormat::executeImpl(std::shared_ptr const&, std::shared_ptr, String const&, DB::ColumnsDescription, bool) const @ 0x0000000011859cbf 17. /build/src/TableFunctions/ITableFunction.cpp:36: DB::ITableFunction::execute(std::shared_ptr const&, std::shared_ptr, String const&, DB::ColumnsDescription, bool, bool) const @ 0x00000000131e9fc3 18. /build/src/Interpreters/Context.cpp:2501: DB::Context::executeTableFunction(std::shared_ptr const&, std::shared_ptr const&) @ 0x00000000144345b2 19. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:4975: DB::QueryAnalyzer::resolveTableFunction(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&, bool) @ 0x000000001401e9f9 20. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5342: DB::QueryAnalyzer::resolveQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&) @ 0x00000000140452bf 21. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5597: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000140136f0 22. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000140127f9 23. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000014011fce 24. /build/src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000001406ce8a 25. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000014973b42 26. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000001497268d 27. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000014974d24 28. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001492924b 29. /build/src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88641 30. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 31. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 2025.07.28 11:50:19.574836 [ 7630 ] {280be916-57af-4c28-b26f-3773ac7f58a9} 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.6.10636.altinitytest (altinity build)) (from [::1]:59958) (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. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x000000000a080b2b 4. /build/src/IO/ReadHelpers.cpp:95: DB::throwAtAssertionFailed(char const*, DB::ReadBuffer&) @ 0x000000000fc6bcc9 5. /build/src/IO/ReadHelpers.h:204: DB::CSVFormatReader::skipFieldDelimiter() @ 0x0000000016a79787 6. /build/src/Processors/Formats/RowInputFormatWithNamesAndTypes.cpp:299: DB::RowInputFormatWithNamesAndTypes::readRow(std::vector::mutable_ptr, std::allocator::mutable_ptr>>&, DB::RowReadExtension&) @ 0x0000000016a4ab1e 7. /build/src/Processors/Formats/IRowInputFormat.cpp:143: DB::IRowInputFormat::read() @ 0x0000000016a1fc72 8. /build/src/Processors/Formats/IInputFormat.cpp:19: DB::IInputFormat::generate() @ 0x00000000169c5536 9. /build/src/Processors/ISource.cpp:139: DB::ISource::tryGenerate() @ 0x00000000169a24fa 10. /build/src/Processors/ISource.cpp:108: DB::ISource::work() @ 0x00000000169a21e7 11. /build/src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x00000000169bd00f 12. /build/src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x00000000169b2105 13. /build/src/Processors/Executors/PipelineExecutor.cpp:170: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x00000000169b16a7 14. /build/src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x00000000169c081c 15. /build/src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x00000000169c0978 16. /build/src/TableFunctions/TableFunctionFormat.cpp:125: DB::(anonymous namespace)::TableFunctionFormat::executeImpl(std::shared_ptr const&, std::shared_ptr, String const&, DB::ColumnsDescription, bool) const @ 0x0000000011859cbf 17. /build/src/TableFunctions/ITableFunction.cpp:36: DB::ITableFunction::execute(std::shared_ptr const&, std::shared_ptr, String const&, DB::ColumnsDescription, bool, bool) const @ 0x00000000131e9fc3 18. /build/src/Interpreters/Context.cpp:2501: DB::Context::executeTableFunction(std::shared_ptr const&, std::shared_ptr const&) @ 0x00000000144345b2 19. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:4975: DB::QueryAnalyzer::resolveTableFunction(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&, bool) @ 0x000000001401e9f9 20. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5342: DB::QueryAnalyzer::resolveQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&) @ 0x00000000140452bf 21. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5597: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000140136f0 22. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000140127f9 23. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000014011fce 24. /build/src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000001406ce8a 25. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000014973b42 26. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000001497268d 27. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000014974d24 28. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001492924b 29. /build/src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88641 30. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 31. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 2025.07.28 11:50:19.593571 [ 7630 ] {} 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. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x000000000a080b2b 4. /build/src/IO/ReadHelpers.cpp:95: DB::throwAtAssertionFailed(char const*, DB::ReadBuffer&) @ 0x000000000fc6bcc9 5. /build/src/IO/ReadHelpers.h:204: DB::CSVFormatReader::skipFieldDelimiter() @ 0x0000000016a79787 6. /build/src/Processors/Formats/RowInputFormatWithNamesAndTypes.cpp:299: DB::RowInputFormatWithNamesAndTypes::readRow(std::vector::mutable_ptr, std::allocator::mutable_ptr>>&, DB::RowReadExtension&) @ 0x0000000016a4ab1e 7. /build/src/Processors/Formats/IRowInputFormat.cpp:143: DB::IRowInputFormat::read() @ 0x0000000016a1fc72 8. /build/src/Processors/Formats/IInputFormat.cpp:19: DB::IInputFormat::generate() @ 0x00000000169c5536 9. /build/src/Processors/ISource.cpp:139: DB::ISource::tryGenerate() @ 0x00000000169a24fa 10. /build/src/Processors/ISource.cpp:108: DB::ISource::work() @ 0x00000000169a21e7 11. /build/src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x00000000169bd00f 12. /build/src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x00000000169b2105 13. /build/src/Processors/Executors/PipelineExecutor.cpp:170: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x00000000169b16a7 14. /build/src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x00000000169c081c 15. /build/src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x00000000169c0978 16. /build/src/TableFunctions/TableFunctionFormat.cpp:125: DB::(anonymous namespace)::TableFunctionFormat::executeImpl(std::shared_ptr const&, std::shared_ptr, String const&, DB::ColumnsDescription, bool) const @ 0x0000000011859cbf 17. /build/src/TableFunctions/ITableFunction.cpp:36: DB::ITableFunction::execute(std::shared_ptr const&, std::shared_ptr, String const&, DB::ColumnsDescription, bool, bool) const @ 0x00000000131e9fc3 18. /build/src/Interpreters/Context.cpp:2501: DB::Context::executeTableFunction(std::shared_ptr const&, std::shared_ptr const&) @ 0x00000000144345b2 19. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:4975: DB::QueryAnalyzer::resolveTableFunction(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&, bool) @ 0x000000001401e9f9 20. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5342: DB::QueryAnalyzer::resolveQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&) @ 0x00000000140452bf 21. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5597: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000140136f0 22. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000140127f9 23. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000014011fce 24. /build/src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000001406ce8a 25. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000014973b42 26. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000001497268d 27. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000014974d24 28. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001492924b 29. /build/src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88641 30. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 31. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 2025.07.28 11:50:19.799355 [ 7630 ] {a2270810-b463-444c-9b44-4a45fb5cbdd2} 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.6.10636.altinitytest (altinity build)) (from [::1]:59958) (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. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x000000000a080b2b 4. /build/src/IO/ReadHelpers.cpp:95: DB::throwAtAssertionFailed(char const*, DB::ReadBuffer&) @ 0x000000000fc6bcc9 5. /build/src/IO/ReadHelpers.cpp:131: ? @ 0x000000000fc6bedc 6. /build/src/Processors/Formats/RowInputFormatWithNamesAndTypes.cpp:299: DB::RowInputFormatWithNamesAndTypes::readRow(std::vector::mutable_ptr, std::allocator::mutable_ptr>>&, DB::RowReadExtension&) @ 0x0000000016a4dd3a 7. /build/src/Processors/Formats/IRowInputFormat.cpp:143: DB::IRowInputFormat::read() @ 0x0000000016a1fc72 8. /build/src/Processors/Formats/IInputFormat.cpp:19: DB::IInputFormat::generate() @ 0x00000000169c5536 9. /build/src/Processors/ISource.cpp:139: DB::ISource::tryGenerate() @ 0x00000000169a24fa 10. /build/src/Processors/ISource.cpp:108: DB::ISource::work() @ 0x00000000169a21e7 11. /build/src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x00000000169bd00f 12. /build/src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x00000000169b2105 13. /build/src/Processors/Executors/PipelineExecutor.cpp:170: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x00000000169b16a7 14. /build/src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x00000000169c081c 15. /build/src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x00000000169c0978 16. /build/src/TableFunctions/TableFunctionFormat.cpp:125: DB::(anonymous namespace)::TableFunctionFormat::executeImpl(std::shared_ptr const&, std::shared_ptr, String const&, DB::ColumnsDescription, bool) const @ 0x0000000011859cbf 17. /build/src/TableFunctions/ITableFunction.cpp:36: DB::ITableFunction::execute(std::shared_ptr const&, std::shared_ptr, String const&, DB::ColumnsDescription, bool, bool) const @ 0x00000000131e9fc3 18. /build/src/Interpreters/Context.cpp:2501: DB::Context::executeTableFunction(std::shared_ptr const&, std::shared_ptr const&) @ 0x00000000144345b2 19. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:4975: DB::QueryAnalyzer::resolveTableFunction(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&, bool) @ 0x000000001401e9f9 20. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5342: DB::QueryAnalyzer::resolveQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&) @ 0x00000000140452bf 21. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5597: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000140136f0 22. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000140127f9 23. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000014011fce 24. /build/src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000001406ce8a 25. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000014973b42 26. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000001497268d 27. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000014974d24 28. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001492924b 29. /build/src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88641 30. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 31. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 2025.07.28 11:50:19.807905 [ 7630 ] {} 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. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x000000000a080b2b 4. /build/src/IO/ReadHelpers.cpp:95: DB::throwAtAssertionFailed(char const*, DB::ReadBuffer&) @ 0x000000000fc6bcc9 5. /build/src/IO/ReadHelpers.cpp:131: ? @ 0x000000000fc6bedc 6. /build/src/Processors/Formats/RowInputFormatWithNamesAndTypes.cpp:299: DB::RowInputFormatWithNamesAndTypes::readRow(std::vector::mutable_ptr, std::allocator::mutable_ptr>>&, DB::RowReadExtension&) @ 0x0000000016a4dd3a 7. /build/src/Processors/Formats/IRowInputFormat.cpp:143: DB::IRowInputFormat::read() @ 0x0000000016a1fc72 8. /build/src/Processors/Formats/IInputFormat.cpp:19: DB::IInputFormat::generate() @ 0x00000000169c5536 9. /build/src/Processors/ISource.cpp:139: DB::ISource::tryGenerate() @ 0x00000000169a24fa 10. /build/src/Processors/ISource.cpp:108: DB::ISource::work() @ 0x00000000169a21e7 11. /build/src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x00000000169bd00f 12. /build/src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x00000000169b2105 13. /build/src/Processors/Executors/PipelineExecutor.cpp:170: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x00000000169b16a7 14. /build/src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x00000000169c081c 15. /build/src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x00000000169c0978 16. /build/src/TableFunctions/TableFunctionFormat.cpp:125: DB::(anonymous namespace)::TableFunctionFormat::executeImpl(std::shared_ptr const&, std::shared_ptr, String const&, DB::ColumnsDescription, bool) const @ 0x0000000011859cbf 17. /build/src/TableFunctions/ITableFunction.cpp:36: DB::ITableFunction::execute(std::shared_ptr const&, std::shared_ptr, String const&, DB::ColumnsDescription, bool, bool) const @ 0x00000000131e9fc3 18. /build/src/Interpreters/Context.cpp:2501: DB::Context::executeTableFunction(std::shared_ptr const&, std::shared_ptr const&) @ 0x00000000144345b2 19. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:4975: DB::QueryAnalyzer::resolveTableFunction(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&, bool) @ 0x000000001401e9f9 20. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5342: DB::QueryAnalyzer::resolveQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&) @ 0x00000000140452bf 21. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5597: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000140136f0 22. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000140127f9 23. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000014011fce 24. /build/src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000001406ce8a 25. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000014973b42 26. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000001497268d 27. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000014974d24 28. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001492924b 29. /build/src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88641 30. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 31. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 2025.07.28 11:50:20.000372 [ 7630 ] {f4131a2e-b85b-4dac-ab82-52a3dd2f502d} 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.6.10636.altinitytest (altinity build)) (from [::1]:59958) (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. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x000000000a080b2b 4. /build/src/IO/ReadHelpers.cpp:95: DB::throwAtAssertionFailed(char const*, DB::ReadBuffer&) @ 0x000000000fc6bcc9 5. /build/src/IO/ReadHelpers.cpp:131: ? @ 0x000000000fc6bedc 6. /build/src/Processors/Formats/RowInputFormatWithNamesAndTypes.cpp:299: DB::RowInputFormatWithNamesAndTypes::readRow(std::vector::mutable_ptr, std::allocator::mutable_ptr>>&, DB::RowReadExtension&) @ 0x0000000016a4dd3a 7. /build/src/Processors/Formats/IRowInputFormat.cpp:143: DB::IRowInputFormat::read() @ 0x0000000016a1fc72 8. /build/src/Processors/Formats/IInputFormat.cpp:19: DB::IInputFormat::generate() @ 0x00000000169c5536 9. /build/src/Processors/ISource.cpp:139: DB::ISource::tryGenerate() @ 0x00000000169a24fa 10. /build/src/Processors/ISource.cpp:108: DB::ISource::work() @ 0x00000000169a21e7 11. /build/src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x00000000169bd00f 12. /build/src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x00000000169b2105 13. /build/src/Processors/Executors/PipelineExecutor.cpp:170: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x00000000169b16a7 14. /build/src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x00000000169c081c 15. /build/src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x00000000169c0978 16. /build/src/TableFunctions/TableFunctionFormat.cpp:125: DB::(anonymous namespace)::TableFunctionFormat::executeImpl(std::shared_ptr const&, std::shared_ptr, String const&, DB::ColumnsDescription, bool) const @ 0x0000000011859cbf 17. /build/src/TableFunctions/ITableFunction.cpp:36: DB::ITableFunction::execute(std::shared_ptr const&, std::shared_ptr, String const&, DB::ColumnsDescription, bool, bool) const @ 0x00000000131e9fc3 18. /build/src/Interpreters/Context.cpp:2501: DB::Context::executeTableFunction(std::shared_ptr const&, std::shared_ptr const&) @ 0x00000000144345b2 19. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:4975: DB::QueryAnalyzer::resolveTableFunction(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&, bool) @ 0x000000001401e9f9 20. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5342: DB::QueryAnalyzer::resolveQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&) @ 0x00000000140452bf 21. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5597: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000140136f0 22. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000140127f9 23. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000014011fce 24. /build/src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000001406ce8a 25. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000014973b42 26. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000001497268d 27. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000014974d24 28. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001492924b 29. /build/src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88641 30. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 31. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 2025.07.28 11:50:20.009673 [ 7630 ] {} 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. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x000000000a080b2b 4. /build/src/IO/ReadHelpers.cpp:95: DB::throwAtAssertionFailed(char const*, DB::ReadBuffer&) @ 0x000000000fc6bcc9 5. /build/src/IO/ReadHelpers.cpp:131: ? @ 0x000000000fc6bedc 6. /build/src/Processors/Formats/RowInputFormatWithNamesAndTypes.cpp:299: DB::RowInputFormatWithNamesAndTypes::readRow(std::vector::mutable_ptr, std::allocator::mutable_ptr>>&, DB::RowReadExtension&) @ 0x0000000016a4dd3a 7. /build/src/Processors/Formats/IRowInputFormat.cpp:143: DB::IRowInputFormat::read() @ 0x0000000016a1fc72 8. /build/src/Processors/Formats/IInputFormat.cpp:19: DB::IInputFormat::generate() @ 0x00000000169c5536 9. /build/src/Processors/ISource.cpp:139: DB::ISource::tryGenerate() @ 0x00000000169a24fa 10. /build/src/Processors/ISource.cpp:108: DB::ISource::work() @ 0x00000000169a21e7 11. /build/src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x00000000169bd00f 12. /build/src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x00000000169b2105 13. /build/src/Processors/Executors/PipelineExecutor.cpp:170: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x00000000169b16a7 14. /build/src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x00000000169c081c 15. /build/src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x00000000169c0978 16. /build/src/TableFunctions/TableFunctionFormat.cpp:125: DB::(anonymous namespace)::TableFunctionFormat::executeImpl(std::shared_ptr const&, std::shared_ptr, String const&, DB::ColumnsDescription, bool) const @ 0x0000000011859cbf 17. /build/src/TableFunctions/ITableFunction.cpp:36: DB::ITableFunction::execute(std::shared_ptr const&, std::shared_ptr, String const&, DB::ColumnsDescription, bool, bool) const @ 0x00000000131e9fc3 18. /build/src/Interpreters/Context.cpp:2501: DB::Context::executeTableFunction(std::shared_ptr const&, std::shared_ptr const&) @ 0x00000000144345b2 19. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:4975: DB::QueryAnalyzer::resolveTableFunction(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&, bool) @ 0x000000001401e9f9 20. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5342: DB::QueryAnalyzer::resolveQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&) @ 0x00000000140452bf 21. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5597: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000140136f0 22. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000140127f9 23. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000014011fce 24. /build/src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000001406ce8a 25. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000014973b42 26. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000001497268d 27. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000014974d24 28. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001492924b 29. /build/src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88641 30. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 31. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 2025.07.28 11:50:20.311860 [ 4587 ] {6fffcc41-ea9b-4f27-8158-d3bbd59589c5} executeQuery: Code: 44. DB::Exception: Cannot create column with type 'Variant(String, UInt32)' because Variant type is not allowed. Set setting enable_variant_type = 1 in order to allow it. (ILLEGAL_COLUMN) (version 25.3.6.10636.altinitytest (altinity build)) (from [::1]:60024) (comment: 03215_validate_type_in_alter_add_modify_column.sql) (query 7, line 8) (in query: alter table test add column bad Variant(UInt32, String);), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x000000000a06b56b 4. /build/src/Interpreters/parseColumnsListForTableFunction.cpp:105: DB::validateDataType(std::shared_ptr const&, DB::DataTypeValidationSettings const&)::$_0::operator()(DB::IDataType const&) const @ 0x0000000014cce784 5. /build/src/Interpreters/parseColumnsListForTableFunction.cpp:171: DB::validateDataType(std::shared_ptr const&, DB::DataTypeValidationSettings const&) @ 0x0000000014ccddff 6. /build/src/Storages/AlterCommands.cpp:1445: DB::AlterCommands::validate(std::shared_ptr const&, std::shared_ptr) const @ 0x0000000015cf4180 7. /build/src/Interpreters/InterpreterAlterQuery.cpp:213: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x00000000148dea74 8. /build/src/Interpreters/InterpreterAlterQuery.cpp:77: DB::InterpreterAlterQuery::execute() @ 0x00000000148dcb0d 9. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88dc9 10. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 11. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 12. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 13. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 14. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 16. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 17. ? @ 0x00007fbc6213eac3 18. ? @ 0x00007fbc621d0850 2025.07.28 11:50:20.317830 [ 4587 ] {} TCPHandler: Code: 44. DB::Exception: Cannot create column with type 'Variant(String, UInt32)' because Variant type is not allowed. Set setting enable_variant_type = 1 in order to allow it. (ILLEGAL_COLUMN), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x000000000a06b56b 4. /build/src/Interpreters/parseColumnsListForTableFunction.cpp:105: DB::validateDataType(std::shared_ptr const&, DB::DataTypeValidationSettings const&)::$_0::operator()(DB::IDataType const&) const @ 0x0000000014cce784 5. /build/src/Interpreters/parseColumnsListForTableFunction.cpp:171: DB::validateDataType(std::shared_ptr const&, DB::DataTypeValidationSettings const&) @ 0x0000000014ccddff 6. /build/src/Storages/AlterCommands.cpp:1445: DB::AlterCommands::validate(std::shared_ptr const&, std::shared_ptr) const @ 0x0000000015cf4180 7. /build/src/Interpreters/InterpreterAlterQuery.cpp:213: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x00000000148dea74 8. /build/src/Interpreters/InterpreterAlterQuery.cpp:77: DB::InterpreterAlterQuery::execute() @ 0x00000000148dcb0d 9. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88dc9 10. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 11. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 12. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 13. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 14. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 16. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 17. ? @ 0x00007fbc6213eac3 18. ? @ 0x00007fbc621d0850 2025.07.28 11:50:20.511465 [ 4587 ] {418e73e7-1115-4ef9-9848-c38cf43e785c} executeQuery: Code: 44. DB::Exception: Cannot create column with type 'Dynamic' because Dynamic type is not allowed. Set setting enable_dynamic_type = 1 in order to allow it. (ILLEGAL_COLUMN) (version 25.3.6.10636.altinitytest (altinity build)) (from [::1]:60024) (comment: 03215_validate_type_in_alter_add_modify_column.sql) (query 8, line 9) (in query: alter table test add column bad Dynamic;), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x000000000a06b56b 4. /build/src/Interpreters/parseColumnsListForTableFunction.cpp:149: DB::validateDataType(std::shared_ptr const&, DB::DataTypeValidationSettings const&)::$_0::operator()(DB::IDataType const&) const @ 0x0000000014cce820 5. /build/src/Interpreters/parseColumnsListForTableFunction.cpp:171: DB::validateDataType(std::shared_ptr const&, DB::DataTypeValidationSettings const&) @ 0x0000000014ccddff 6. /build/src/Storages/AlterCommands.cpp:1445: DB::AlterCommands::validate(std::shared_ptr const&, std::shared_ptr) const @ 0x0000000015cf4180 7. /build/src/Interpreters/InterpreterAlterQuery.cpp:213: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x00000000148dea74 8. /build/src/Interpreters/InterpreterAlterQuery.cpp:77: DB::InterpreterAlterQuery::execute() @ 0x00000000148dcb0d 9. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88dc9 10. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 11. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 12. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 13. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 14. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 16. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 17. ? @ 0x00007fbc6213eac3 18. ? @ 0x00007fbc621d0850 2025.07.28 11:50:20.514638 [ 4587 ] {} TCPHandler: Code: 44. DB::Exception: Cannot create column with type 'Dynamic' because Dynamic type is not allowed. Set setting enable_dynamic_type = 1 in order to allow it. (ILLEGAL_COLUMN), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x000000000a06b56b 4. /build/src/Interpreters/parseColumnsListForTableFunction.cpp:149: DB::validateDataType(std::shared_ptr const&, DB::DataTypeValidationSettings const&)::$_0::operator()(DB::IDataType const&) const @ 0x0000000014cce820 5. /build/src/Interpreters/parseColumnsListForTableFunction.cpp:171: DB::validateDataType(std::shared_ptr const&, DB::DataTypeValidationSettings const&) @ 0x0000000014ccddff 6. /build/src/Storages/AlterCommands.cpp:1445: DB::AlterCommands::validate(std::shared_ptr const&, std::shared_ptr) const @ 0x0000000015cf4180 7. /build/src/Interpreters/InterpreterAlterQuery.cpp:213: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x00000000148dea74 8. /build/src/Interpreters/InterpreterAlterQuery.cpp:77: DB::InterpreterAlterQuery::execute() @ 0x00000000148dcb0d 9. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88dc9 10. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 11. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 12. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 13. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 14. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 16. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 17. ? @ 0x00007fbc6213eac3 18. ? @ 0x00007fbc621d0850 2025.07.28 11:50:20.589697 [ 4587 ] {6cbaa6e7-5c63-4470-8ca9-9695f27ac64d} executeQuery: Code: 455. DB::Exception: Creating columns of type LowCardinality(UInt8) 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.6.10636.altinitytest (altinity build)) (from [::1]:60024) (comment: 03215_validate_type_in_alter_add_modify_column.sql) (query 9, line 10) (in query: alter table test add column bad LowCardinality(UInt8);), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x000000000a06b56b 4. /build/src/Interpreters/parseColumnsListForTableFunction.cpp:67: DB::validateDataType(std::shared_ptr const&, DB::DataTypeValidationSettings const&)::$_0::operator()(DB::IDataType const&) const @ 0x0000000014ccea0b 5. /build/src/Interpreters/parseColumnsListForTableFunction.cpp:171: DB::validateDataType(std::shared_ptr const&, DB::DataTypeValidationSettings const&) @ 0x0000000014ccddff 6. /build/src/Storages/AlterCommands.cpp:1445: DB::AlterCommands::validate(std::shared_ptr const&, std::shared_ptr) const @ 0x0000000015cf4180 7. /build/src/Interpreters/InterpreterAlterQuery.cpp:213: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x00000000148dea74 8. /build/src/Interpreters/InterpreterAlterQuery.cpp:77: DB::InterpreterAlterQuery::execute() @ 0x00000000148dcb0d 9. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88dc9 10. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 11. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 12. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 13. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 14. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 16. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 17. ? @ 0x00007fbc6213eac3 18. ? @ 0x00007fbc621d0850 2025.07.28 11:50:20.612573 [ 4587 ] {} TCPHandler: Code: 455. DB::Exception: Creating columns of type LowCardinality(UInt8) 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. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x000000000a06b56b 4. /build/src/Interpreters/parseColumnsListForTableFunction.cpp:67: DB::validateDataType(std::shared_ptr const&, DB::DataTypeValidationSettings const&)::$_0::operator()(DB::IDataType const&) const @ 0x0000000014ccea0b 5. /build/src/Interpreters/parseColumnsListForTableFunction.cpp:171: DB::validateDataType(std::shared_ptr const&, DB::DataTypeValidationSettings const&) @ 0x0000000014ccddff 6. /build/src/Storages/AlterCommands.cpp:1445: DB::AlterCommands::validate(std::shared_ptr const&, std::shared_ptr) const @ 0x0000000015cf4180 7. /build/src/Interpreters/InterpreterAlterQuery.cpp:213: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x00000000148dea74 8. /build/src/Interpreters/InterpreterAlterQuery.cpp:77: DB::InterpreterAlterQuery::execute() @ 0x00000000148dcb0d 9. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88dc9 10. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 11. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 12. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 13. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 14. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 16. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 17. ? @ 0x00007fbc6213eac3 18. ? @ 0x00007fbc621d0850 2025.07.28 11:50:20.695913 [ 4587 ] {04489b44-80a8-4b21-88ec-db9fdebb376d} executeQuery: Code: 44. DB::Exception: Cannot create column with type 'FixedString(10000)' 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.6.10636.altinitytest (altinity build)) (from [::1]:60024) (comment: 03215_validate_type_in_alter_add_modify_column.sql) (query 10, line 11) (in query: alter table test add column bad FixedString(10000);), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, unsigned long const&) @ 0x000000000a3d916b 4. /build/src/Interpreters/parseColumnsListForTableFunction.cpp:92: DB::validateDataType(std::shared_ptr const&, DB::DataTypeValidationSettings const&)::$_0::operator()(DB::IDataType const&) const @ 0x0000000014cce8bf 5. /build/src/Interpreters/parseColumnsListForTableFunction.cpp:171: DB::validateDataType(std::shared_ptr const&, DB::DataTypeValidationSettings const&) @ 0x0000000014ccddff 6. /build/src/Storages/AlterCommands.cpp:1445: DB::AlterCommands::validate(std::shared_ptr const&, std::shared_ptr) const @ 0x0000000015cf4180 7. /build/src/Interpreters/InterpreterAlterQuery.cpp:213: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x00000000148dea74 8. /build/src/Interpreters/InterpreterAlterQuery.cpp:77: DB::InterpreterAlterQuery::execute() @ 0x00000000148dcb0d 9. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88dc9 10. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 11. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 12. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 13. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 14. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 16. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 17. ? @ 0x00007fbc6213eac3 18. ? @ 0x00007fbc621d0850 2025.07.28 11:50:20.703262 [ 4587 ] {} TCPHandler: Code: 44. DB::Exception: Cannot create column with type 'FixedString(10000)' 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. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, unsigned long const&) @ 0x000000000a3d916b 4. /build/src/Interpreters/parseColumnsListForTableFunction.cpp:92: DB::validateDataType(std::shared_ptr const&, DB::DataTypeValidationSettings const&)::$_0::operator()(DB::IDataType const&) const @ 0x0000000014cce8bf 5. /build/src/Interpreters/parseColumnsListForTableFunction.cpp:171: DB::validateDataType(std::shared_ptr const&, DB::DataTypeValidationSettings const&) @ 0x0000000014ccddff 6. /build/src/Storages/AlterCommands.cpp:1445: DB::AlterCommands::validate(std::shared_ptr const&, std::shared_ptr) const @ 0x0000000015cf4180 7. /build/src/Interpreters/InterpreterAlterQuery.cpp:213: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x00000000148dea74 8. /build/src/Interpreters/InterpreterAlterQuery.cpp:77: DB::InterpreterAlterQuery::execute() @ 0x00000000148dcb0d 9. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88dc9 10. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 11. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 12. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 13. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 14. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 16. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 17. ? @ 0x00007fbc6213eac3 18. ? @ 0x00007fbc621d0850 2025.07.28 11:50:20.796016 [ 4587 ] {8b60966a-e738-4232-83f0-ae7d54e5dc4d} executeQuery: Code: 44. DB::Exception: Cannot create column with type 'Variant(String, UInt32)' because Variant type is not allowed. Set setting enable_variant_type = 1 in order to allow it. (ILLEGAL_COLUMN) (version 25.3.6.10636.altinitytest (altinity build)) (from [::1]:60024) (comment: 03215_validate_type_in_alter_add_modify_column.sql) (query 11, line 13) (in query: alter table test modify column id Variant(UInt32, String);), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x000000000a06b56b 4. /build/src/Interpreters/parseColumnsListForTableFunction.cpp:105: DB::validateDataType(std::shared_ptr const&, DB::DataTypeValidationSettings const&)::$_0::operator()(DB::IDataType const&) const @ 0x0000000014cce784 5. /build/src/Interpreters/parseColumnsListForTableFunction.cpp:171: DB::validateDataType(std::shared_ptr const&, DB::DataTypeValidationSettings const&) @ 0x0000000014ccddff 6. /build/src/Storages/AlterCommands.cpp:1533: DB::AlterCommands::validate(std::shared_ptr const&, std::shared_ptr) const @ 0x0000000015cf4a4c 7. /build/src/Interpreters/InterpreterAlterQuery.cpp:213: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x00000000148dea74 8. /build/src/Interpreters/InterpreterAlterQuery.cpp:77: DB::InterpreterAlterQuery::execute() @ 0x00000000148dcb0d 9. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88dc9 10. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 11. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 12. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 13. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 14. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 16. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 17. ? @ 0x00007fbc6213eac3 18. ? @ 0x00007fbc621d0850 2025.07.28 11:50:20.807286 [ 4587 ] {} TCPHandler: Code: 44. DB::Exception: Cannot create column with type 'Variant(String, UInt32)' because Variant type is not allowed. Set setting enable_variant_type = 1 in order to allow it. (ILLEGAL_COLUMN), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x000000000a06b56b 4. /build/src/Interpreters/parseColumnsListForTableFunction.cpp:105: DB::validateDataType(std::shared_ptr const&, DB::DataTypeValidationSettings const&)::$_0::operator()(DB::IDataType const&) const @ 0x0000000014cce784 5. /build/src/Interpreters/parseColumnsListForTableFunction.cpp:171: DB::validateDataType(std::shared_ptr const&, DB::DataTypeValidationSettings const&) @ 0x0000000014ccddff 6. /build/src/Storages/AlterCommands.cpp:1533: DB::AlterCommands::validate(std::shared_ptr const&, std::shared_ptr) const @ 0x0000000015cf4a4c 7. /build/src/Interpreters/InterpreterAlterQuery.cpp:213: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x00000000148dea74 8. /build/src/Interpreters/InterpreterAlterQuery.cpp:77: DB::InterpreterAlterQuery::execute() @ 0x00000000148dcb0d 9. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88dc9 10. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 11. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 12. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 13. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 14. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 16. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 17. ? @ 0x00007fbc6213eac3 18. ? @ 0x00007fbc621d0850 2025.07.28 11:50:20.872695 [ 7625 ] {fa4ebe74-ace7-4436-8e68-447b5cc6da56} executeQuery: Code: 59. DB::Exception: Illegal type Int128 of column for filter. (ILLEGAL_TYPE_OF_COLUMN_FOR_FILTER) (version 25.3.6.10636.altinitytest (altinity build)) (from [::1]:60050) (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. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x000000000a06b56b 4. /build/src/Processors/QueryPlan/SourceStepWithFilter.cpp:69: DB::SourceStepWithFilter::applyPrewhereActions(DB::Block, std::shared_ptr const&) @ 0x0000000016ea0bf0 5. /build/src/Storages/MergeTree/MergeTreeSelectProcessor.cpp:265: DB::MergeTreeSelectProcessor::transformHeader(DB::Block, std::shared_ptr const&) @ 0x00000000164c05c4 6. /build/src/Processors/QueryPlan/ReadFromMergeTree.cpp:348: 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) @ 0x0000000016e1c7c7 7. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107], 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&) @ 0x0000000016401cd2 8. /build/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 @ 0x00000000163ec114 9. /build/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 @ 0x00000000163ebef8 10. /build/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) @ 0x0000000016635568 11. /build/src/Planner/PlannerJoinTree.cpp:946: DB::(anonymous namespace)::buildQueryPlanForTableExpression(std::shared_ptr, std::shared_ptr const&, DB::SelectQueryInfo const&, DB::SelectQueryOptions const&, std::shared_ptr&, bool, bool) @ 0x00000000149970ee 12. /build/src/Planner/PlannerJoinTree.cpp:2252: DB::buildJoinTreeQueryPlan(std::shared_ptr const&, DB::SelectQueryInfo const&, DB::SelectQueryOptions&, std::unordered_set, std::equal_to, std::allocator> const&, std::shared_ptr&) @ 0x000000001498e109 13. /build/src/Planner/Planner.cpp:1553: DB::Planner::buildPlanForQueryNode() @ 0x0000000014979dae 14. /build/src/Planner/Planner.cpp:1308: DB::Planner::buildQueryPlanIfNeeded() @ 0x000000001497685c 15. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:255: DB::InterpreterSelectQueryAnalyzer::getQueryPlan() @ 0x000000001497476d 16. /build/src/Interpreters/executeQuery.cpp:1405: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88806 17. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 18. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 19. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 20. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 21. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 22. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 23. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 24. ? @ 0x00007fbc6213eac3 25. ? @ 0x00007fbc621d0850 2025.07.28 11:50:20.877682 [ 4587 ] {8bee0cba-ab16-4680-acbe-ca86df4ffdea} executeQuery: Code: 44. DB::Exception: Cannot create column with type 'Dynamic' because Dynamic type is not allowed. Set setting enable_dynamic_type = 1 in order to allow it. (ILLEGAL_COLUMN) (version 25.3.6.10636.altinitytest (altinity build)) (from [::1]:60024) (comment: 03215_validate_type_in_alter_add_modify_column.sql) (query 12, line 14) (in query: alter table test modify column id Dynamic;), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x000000000a06b56b 4. /build/src/Interpreters/parseColumnsListForTableFunction.cpp:149: DB::validateDataType(std::shared_ptr const&, DB::DataTypeValidationSettings const&)::$_0::operator()(DB::IDataType const&) const @ 0x0000000014cce820 5. /build/src/Interpreters/parseColumnsListForTableFunction.cpp:171: DB::validateDataType(std::shared_ptr const&, DB::DataTypeValidationSettings const&) @ 0x0000000014ccddff 6. /build/src/Storages/AlterCommands.cpp:1533: DB::AlterCommands::validate(std::shared_ptr const&, std::shared_ptr) const @ 0x0000000015cf4a4c 7. /build/src/Interpreters/InterpreterAlterQuery.cpp:213: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x00000000148dea74 8. /build/src/Interpreters/InterpreterAlterQuery.cpp:77: DB::InterpreterAlterQuery::execute() @ 0x00000000148dcb0d 9. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88dc9 10. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 11. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 12. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 13. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 14. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 16. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 17. ? @ 0x00007fbc6213eac3 18. ? @ 0x00007fbc621d0850 2025.07.28 11:50:20.881549 [ 7625 ] {} 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. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x000000000a06b56b 4. /build/src/Processors/QueryPlan/SourceStepWithFilter.cpp:69: DB::SourceStepWithFilter::applyPrewhereActions(DB::Block, std::shared_ptr const&) @ 0x0000000016ea0bf0 5. /build/src/Storages/MergeTree/MergeTreeSelectProcessor.cpp:265: DB::MergeTreeSelectProcessor::transformHeader(DB::Block, std::shared_ptr const&) @ 0x00000000164c05c4 6. /build/src/Processors/QueryPlan/ReadFromMergeTree.cpp:348: 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) @ 0x0000000016e1c7c7 7. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107], 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&) @ 0x0000000016401cd2 8. /build/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 @ 0x00000000163ec114 9. /build/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 @ 0x00000000163ebef8 10. /build/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) @ 0x0000000016635568 11. /build/src/Planner/PlannerJoinTree.cpp:946: DB::(anonymous namespace)::buildQueryPlanForTableExpression(std::shared_ptr, std::shared_ptr const&, DB::SelectQueryInfo const&, DB::SelectQueryOptions const&, std::shared_ptr&, bool, bool) @ 0x00000000149970ee 12. /build/src/Planner/PlannerJoinTree.cpp:2252: DB::buildJoinTreeQueryPlan(std::shared_ptr const&, DB::SelectQueryInfo const&, DB::SelectQueryOptions&, std::unordered_set, std::equal_to, std::allocator> const&, std::shared_ptr&) @ 0x000000001498e109 13. /build/src/Planner/Planner.cpp:1553: DB::Planner::buildPlanForQueryNode() @ 0x0000000014979dae 14. /build/src/Planner/Planner.cpp:1308: DB::Planner::buildQueryPlanIfNeeded() @ 0x000000001497685c 15. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:255: DB::InterpreterSelectQueryAnalyzer::getQueryPlan() @ 0x000000001497476d 16. /build/src/Interpreters/executeQuery.cpp:1405: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88806 17. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 18. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 19. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 20. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 21. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 22. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 23. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 24. ? @ 0x00007fbc6213eac3 25. ? @ 0x00007fbc621d0850 2025.07.28 11:50:20.881650 [ 4587 ] {} TCPHandler: Code: 44. DB::Exception: Cannot create column with type 'Dynamic' because Dynamic type is not allowed. Set setting enable_dynamic_type = 1 in order to allow it. (ILLEGAL_COLUMN), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x000000000a06b56b 4. /build/src/Interpreters/parseColumnsListForTableFunction.cpp:149: DB::validateDataType(std::shared_ptr const&, DB::DataTypeValidationSettings const&)::$_0::operator()(DB::IDataType const&) const @ 0x0000000014cce820 5. /build/src/Interpreters/parseColumnsListForTableFunction.cpp:171: DB::validateDataType(std::shared_ptr const&, DB::DataTypeValidationSettings const&) @ 0x0000000014ccddff 6. /build/src/Storages/AlterCommands.cpp:1533: DB::AlterCommands::validate(std::shared_ptr const&, std::shared_ptr) const @ 0x0000000015cf4a4c 7. /build/src/Interpreters/InterpreterAlterQuery.cpp:213: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x00000000148dea74 8. /build/src/Interpreters/InterpreterAlterQuery.cpp:77: DB::InterpreterAlterQuery::execute() @ 0x00000000148dcb0d 9. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88dc9 10. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 11. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 12. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 13. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 14. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 16. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 17. ? @ 0x00007fbc6213eac3 18. ? @ 0x00007fbc621d0850 2025.07.28 11:50:21.042959 [ 4587 ] {74c7f772-4da5-4a0f-a820-221014ee03fc} executeQuery: Code: 455. DB::Exception: Creating columns of type LowCardinality(UInt8) 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.6.10636.altinitytest (altinity build)) (from [::1]:60024) (comment: 03215_validate_type_in_alter_add_modify_column.sql) (query 13, line 15) (in query: alter table test modify column id LowCardinality(UInt8);), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x000000000a06b56b 4. /build/src/Interpreters/parseColumnsListForTableFunction.cpp:67: DB::validateDataType(std::shared_ptr const&, DB::DataTypeValidationSettings const&)::$_0::operator()(DB::IDataType const&) const @ 0x0000000014ccea0b 5. /build/src/Interpreters/parseColumnsListForTableFunction.cpp:171: DB::validateDataType(std::shared_ptr const&, DB::DataTypeValidationSettings const&) @ 0x0000000014ccddff 6. /build/src/Storages/AlterCommands.cpp:1533: DB::AlterCommands::validate(std::shared_ptr const&, std::shared_ptr) const @ 0x0000000015cf4a4c 7. /build/src/Interpreters/InterpreterAlterQuery.cpp:213: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x00000000148dea74 8. /build/src/Interpreters/InterpreterAlterQuery.cpp:77: DB::InterpreterAlterQuery::execute() @ 0x00000000148dcb0d 9. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88dc9 10. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 11. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 12. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 13. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 14. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 16. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 17. ? @ 0x00007fbc6213eac3 18. ? @ 0x00007fbc621d0850 2025.07.28 11:50:21.050753 [ 4587 ] {} TCPHandler: Code: 455. DB::Exception: Creating columns of type LowCardinality(UInt8) 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. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x000000000a06b56b 4. /build/src/Interpreters/parseColumnsListForTableFunction.cpp:67: DB::validateDataType(std::shared_ptr const&, DB::DataTypeValidationSettings const&)::$_0::operator()(DB::IDataType const&) const @ 0x0000000014ccea0b 5. /build/src/Interpreters/parseColumnsListForTableFunction.cpp:171: DB::validateDataType(std::shared_ptr const&, DB::DataTypeValidationSettings const&) @ 0x0000000014ccddff 6. /build/src/Storages/AlterCommands.cpp:1533: DB::AlterCommands::validate(std::shared_ptr const&, std::shared_ptr) const @ 0x0000000015cf4a4c 7. /build/src/Interpreters/InterpreterAlterQuery.cpp:213: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x00000000148dea74 8. /build/src/Interpreters/InterpreterAlterQuery.cpp:77: DB::InterpreterAlterQuery::execute() @ 0x00000000148dcb0d 9. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88dc9 10. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 11. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 12. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 13. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 14. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 16. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 17. ? @ 0x00007fbc6213eac3 18. ? @ 0x00007fbc621d0850 2025.07.28 11:50:21.255915 [ 5747 ] {} 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. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception>&, String>(int, FormatStringHelperImpl>&>::type, std::type_identity::type>, std::basic_string_view>&, String&&) @ 0x000000001385a5eb 4. /build/src/Access/SettingsConstraints.cpp:376: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000013859b18 5. /build/src/Access/SettingsConstraints.cpp:300: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000013858faf 6. /build/src/Access/SettingsConstraints.cpp:209: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000013859223 7. /build/src/Interpreters/Context.cpp:2690: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000014436134 8. /build/src/Interpreters/Context.cpp:2729: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x000000001443662b 9. /build/src/Server/HTTPHandler.cpp:457: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000001686d165 10. /build/src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x0000000016870807 11. /build/src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x0000000016907e99 12. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 13. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 14. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 15. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 16. ? @ 0x00007fbc6213eac3 17. ? @ 0x00007fbc621d0850 (version 25.3.6.10636.altinitytest (altinity build)) 2025.07.28 11:50:21.268748 [ 4587 ] {b4cdf694-0f85-4f1e-82e7-2458e2f62892} executeQuery: Code: 44. DB::Exception: Cannot create column with type 'FixedString(10000)' 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.6.10636.altinitytest (altinity build)) (from [::1]:60024) (comment: 03215_validate_type_in_alter_add_modify_column.sql) (query 14, line 16) (in query: alter table test modify column id FixedString(10000);), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, unsigned long const&) @ 0x000000000a3d916b 4. /build/src/Interpreters/parseColumnsListForTableFunction.cpp:92: DB::validateDataType(std::shared_ptr const&, DB::DataTypeValidationSettings const&)::$_0::operator()(DB::IDataType const&) const @ 0x0000000014cce8bf 5. /build/src/Interpreters/parseColumnsListForTableFunction.cpp:171: DB::validateDataType(std::shared_ptr const&, DB::DataTypeValidationSettings const&) @ 0x0000000014ccddff 6. /build/src/Storages/AlterCommands.cpp:1533: DB::AlterCommands::validate(std::shared_ptr const&, std::shared_ptr) const @ 0x0000000015cf4a4c 7. /build/src/Interpreters/InterpreterAlterQuery.cpp:213: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x00000000148dea74 8. /build/src/Interpreters/InterpreterAlterQuery.cpp:77: DB::InterpreterAlterQuery::execute() @ 0x00000000148dcb0d 9. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88dc9 10. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 11. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 12. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 13. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 14. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 16. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 17. ? @ 0x00007fbc6213eac3 18. ? @ 0x00007fbc621d0850 2025.07.28 11:50:21.273495 [ 4587 ] {} TCPHandler: Code: 44. DB::Exception: Cannot create column with type 'FixedString(10000)' 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. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, unsigned long const&) @ 0x000000000a3d916b 4. /build/src/Interpreters/parseColumnsListForTableFunction.cpp:92: DB::validateDataType(std::shared_ptr const&, DB::DataTypeValidationSettings const&)::$_0::operator()(DB::IDataType const&) const @ 0x0000000014cce8bf 5. /build/src/Interpreters/parseColumnsListForTableFunction.cpp:171: DB::validateDataType(std::shared_ptr const&, DB::DataTypeValidationSettings const&) @ 0x0000000014ccddff 6. /build/src/Storages/AlterCommands.cpp:1533: DB::AlterCommands::validate(std::shared_ptr const&, std::shared_ptr) const @ 0x0000000015cf4a4c 7. /build/src/Interpreters/InterpreterAlterQuery.cpp:213: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x00000000148dea74 8. /build/src/Interpreters/InterpreterAlterQuery.cpp:77: DB::InterpreterAlterQuery::execute() @ 0x00000000148dcb0d 9. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88dc9 10. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 11. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 12. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 13. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 14. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 16. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 17. ? @ 0x00007fbc6213eac3 18. ? @ 0x00007fbc621d0850 2025.07.28 11:50:21.376669 [ 7625 ] {8aedfa83-4814-4f98-8fd1-363228233d93} executeQuery: Code: 59. DB::Exception: Illegal type Int256 of column for filter. (ILLEGAL_TYPE_OF_COLUMN_FOR_FILTER) (version 25.3.6.10636.altinitytest (altinity build)) (from [::1]:60050) (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. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x000000000a06b56b 4. /build/src/Processors/QueryPlan/SourceStepWithFilter.cpp:69: DB::SourceStepWithFilter::applyPrewhereActions(DB::Block, std::shared_ptr const&) @ 0x0000000016ea0bf0 5. /build/src/Storages/MergeTree/MergeTreeSelectProcessor.cpp:265: DB::MergeTreeSelectProcessor::transformHeader(DB::Block, std::shared_ptr const&) @ 0x00000000164c05c4 6. /build/src/Processors/QueryPlan/ReadFromMergeTree.cpp:348: 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) @ 0x0000000016e1c7c7 7. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107], 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&) @ 0x0000000016401cd2 8. /build/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 @ 0x00000000163ec114 9. /build/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 @ 0x00000000163ebef8 10. /build/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) @ 0x0000000016635568 11. /build/src/Planner/PlannerJoinTree.cpp:946: DB::(anonymous namespace)::buildQueryPlanForTableExpression(std::shared_ptr, std::shared_ptr const&, DB::SelectQueryInfo const&, DB::SelectQueryOptions const&, std::shared_ptr&, bool, bool) @ 0x00000000149970ee 12. /build/src/Planner/PlannerJoinTree.cpp:2252: DB::buildJoinTreeQueryPlan(std::shared_ptr const&, DB::SelectQueryInfo const&, DB::SelectQueryOptions&, std::unordered_set, std::equal_to, std::allocator> const&, std::shared_ptr&) @ 0x000000001498e109 13. /build/src/Planner/Planner.cpp:1553: DB::Planner::buildPlanForQueryNode() @ 0x0000000014979dae 14. /build/src/Planner/Planner.cpp:1308: DB::Planner::buildQueryPlanIfNeeded() @ 0x000000001497685c 15. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:255: DB::InterpreterSelectQueryAnalyzer::getQueryPlan() @ 0x000000001497476d 16. /build/src/Interpreters/executeQuery.cpp:1405: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88806 17. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 18. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 19. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 20. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 21. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 22. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 23. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 24. ? @ 0x00007fbc6213eac3 25. ? @ 0x00007fbc621d0850 2025.07.28 11:50:21.382097 [ 7625 ] {} 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. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x000000000a06b56b 4. /build/src/Processors/QueryPlan/SourceStepWithFilter.cpp:69: DB::SourceStepWithFilter::applyPrewhereActions(DB::Block, std::shared_ptr const&) @ 0x0000000016ea0bf0 5. /build/src/Storages/MergeTree/MergeTreeSelectProcessor.cpp:265: DB::MergeTreeSelectProcessor::transformHeader(DB::Block, std::shared_ptr const&) @ 0x00000000164c05c4 6. /build/src/Processors/QueryPlan/ReadFromMergeTree.cpp:348: 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) @ 0x0000000016e1c7c7 7. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107], 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&) @ 0x0000000016401cd2 8. /build/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 @ 0x00000000163ec114 9. /build/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 @ 0x00000000163ebef8 10. /build/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) @ 0x0000000016635568 11. /build/src/Planner/PlannerJoinTree.cpp:946: DB::(anonymous namespace)::buildQueryPlanForTableExpression(std::shared_ptr, std::shared_ptr const&, DB::SelectQueryInfo const&, DB::SelectQueryOptions const&, std::shared_ptr&, bool, bool) @ 0x00000000149970ee 12. /build/src/Planner/PlannerJoinTree.cpp:2252: DB::buildJoinTreeQueryPlan(std::shared_ptr const&, DB::SelectQueryInfo const&, DB::SelectQueryOptions&, std::unordered_set, std::equal_to, std::allocator> const&, std::shared_ptr&) @ 0x000000001498e109 13. /build/src/Planner/Planner.cpp:1553: DB::Planner::buildPlanForQueryNode() @ 0x0000000014979dae 14. /build/src/Planner/Planner.cpp:1308: DB::Planner::buildQueryPlanIfNeeded() @ 0x000000001497685c 15. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:255: DB::InterpreterSelectQueryAnalyzer::getQueryPlan() @ 0x000000001497476d 16. /build/src/Interpreters/executeQuery.cpp:1405: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88806 17. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 18. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 19. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 20. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 21. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 22. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 23. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 24. ? @ 0x00007fbc6213eac3 25. ? @ 0x00007fbc621d0850 2025.07.28 11:50:21.875144 [ 7625 ] {ff7a333d-c53f-4042-87bd-b55a44b463f7} executeQuery: Code: 59. DB::Exception: Illegal type UInt128 of column for filter. (ILLEGAL_TYPE_OF_COLUMN_FOR_FILTER) (version 25.3.6.10636.altinitytest (altinity build)) (from [::1]:60050) (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. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x000000000a06b56b 4. /build/src/Processors/QueryPlan/SourceStepWithFilter.cpp:69: DB::SourceStepWithFilter::applyPrewhereActions(DB::Block, std::shared_ptr const&) @ 0x0000000016ea0bf0 5. /build/src/Storages/MergeTree/MergeTreeSelectProcessor.cpp:265: DB::MergeTreeSelectProcessor::transformHeader(DB::Block, std::shared_ptr const&) @ 0x00000000164c05c4 6. /build/src/Processors/QueryPlan/ReadFromMergeTree.cpp:348: 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) @ 0x0000000016e1c7c7 7. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107], 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&) @ 0x0000000016401cd2 8. /build/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 @ 0x00000000163ec114 9. /build/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 @ 0x00000000163ebef8 10. /build/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) @ 0x0000000016635568 11. /build/src/Planner/PlannerJoinTree.cpp:946: DB::(anonymous namespace)::buildQueryPlanForTableExpression(std::shared_ptr, std::shared_ptr const&, DB::SelectQueryInfo const&, DB::SelectQueryOptions const&, std::shared_ptr&, bool, bool) @ 0x00000000149970ee 12. /build/src/Planner/PlannerJoinTree.cpp:2252: DB::buildJoinTreeQueryPlan(std::shared_ptr const&, DB::SelectQueryInfo const&, DB::SelectQueryOptions&, std::unordered_set, std::equal_to, std::allocator> const&, std::shared_ptr&) @ 0x000000001498e109 13. /build/src/Planner/Planner.cpp:1553: DB::Planner::buildPlanForQueryNode() @ 0x0000000014979dae 14. /build/src/Planner/Planner.cpp:1308: DB::Planner::buildQueryPlanIfNeeded() @ 0x000000001497685c 15. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:255: DB::InterpreterSelectQueryAnalyzer::getQueryPlan() @ 0x000000001497476d 16. /build/src/Interpreters/executeQuery.cpp:1405: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88806 17. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 18. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 19. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 20. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 21. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 22. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 23. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 24. ? @ 0x00007fbc6213eac3 25. ? @ 0x00007fbc621d0850 2025.07.28 11:50:21.888663 [ 7625 ] {} 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. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x000000000a06b56b 4. /build/src/Processors/QueryPlan/SourceStepWithFilter.cpp:69: DB::SourceStepWithFilter::applyPrewhereActions(DB::Block, std::shared_ptr const&) @ 0x0000000016ea0bf0 5. /build/src/Storages/MergeTree/MergeTreeSelectProcessor.cpp:265: DB::MergeTreeSelectProcessor::transformHeader(DB::Block, std::shared_ptr const&) @ 0x00000000164c05c4 6. /build/src/Processors/QueryPlan/ReadFromMergeTree.cpp:348: 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) @ 0x0000000016e1c7c7 7. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107], 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&) @ 0x0000000016401cd2 8. /build/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 @ 0x00000000163ec114 9. /build/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 @ 0x00000000163ebef8 10. /build/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) @ 0x0000000016635568 11. /build/src/Planner/PlannerJoinTree.cpp:946: DB::(anonymous namespace)::buildQueryPlanForTableExpression(std::shared_ptr, std::shared_ptr const&, DB::SelectQueryInfo const&, DB::SelectQueryOptions const&, std::shared_ptr&, bool, bool) @ 0x00000000149970ee 12. /build/src/Planner/PlannerJoinTree.cpp:2252: DB::buildJoinTreeQueryPlan(std::shared_ptr const&, DB::SelectQueryInfo const&, DB::SelectQueryOptions&, std::unordered_set, std::equal_to, std::allocator> const&, std::shared_ptr&) @ 0x000000001498e109 13. /build/src/Planner/Planner.cpp:1553: DB::Planner::buildPlanForQueryNode() @ 0x0000000014979dae 14. /build/src/Planner/Planner.cpp:1308: DB::Planner::buildQueryPlanIfNeeded() @ 0x000000001497685c 15. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:255: DB::InterpreterSelectQueryAnalyzer::getQueryPlan() @ 0x000000001497476d 16. /build/src/Interpreters/executeQuery.cpp:1405: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88806 17. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 18. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 19. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 20. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 21. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 22. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 23. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 24. ? @ 0x00007fbc6213eac3 25. ? @ 0x00007fbc621d0850 2025.07.28 11:50:22.489449 [ 7625 ] {d242410f-aee7-4feb-9b84-e5a96fb32767} executeQuery: Code: 59. DB::Exception: Illegal type UInt256 of column for filter. (ILLEGAL_TYPE_OF_COLUMN_FOR_FILTER) (version 25.3.6.10636.altinitytest (altinity build)) (from [::1]:60050) (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. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x000000000a06b56b 4. /build/src/Processors/QueryPlan/SourceStepWithFilter.cpp:69: DB::SourceStepWithFilter::applyPrewhereActions(DB::Block, std::shared_ptr const&) @ 0x0000000016ea0bf0 5. /build/src/Storages/MergeTree/MergeTreeSelectProcessor.cpp:265: DB::MergeTreeSelectProcessor::transformHeader(DB::Block, std::shared_ptr const&) @ 0x00000000164c05c4 6. /build/src/Processors/QueryPlan/ReadFromMergeTree.cpp:348: 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) @ 0x0000000016e1c7c7 7. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107], 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&) @ 0x0000000016401cd2 8. /build/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 @ 0x00000000163ec114 9. /build/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 @ 0x00000000163ebef8 10. /build/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) @ 0x0000000016635568 11. /build/src/Planner/PlannerJoinTree.cpp:946: DB::(anonymous namespace)::buildQueryPlanForTableExpression(std::shared_ptr, std::shared_ptr const&, DB::SelectQueryInfo const&, DB::SelectQueryOptions const&, std::shared_ptr&, bool, bool) @ 0x00000000149970ee 12. /build/src/Planner/PlannerJoinTree.cpp:2252: DB::buildJoinTreeQueryPlan(std::shared_ptr const&, DB::SelectQueryInfo const&, DB::SelectQueryOptions&, std::unordered_set, std::equal_to, std::allocator> const&, std::shared_ptr&) @ 0x000000001498e109 13. /build/src/Planner/Planner.cpp:1553: DB::Planner::buildPlanForQueryNode() @ 0x0000000014979dae 14. /build/src/Planner/Planner.cpp:1308: DB::Planner::buildQueryPlanIfNeeded() @ 0x000000001497685c 15. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:255: DB::InterpreterSelectQueryAnalyzer::getQueryPlan() @ 0x000000001497476d 16. /build/src/Interpreters/executeQuery.cpp:1405: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88806 17. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 18. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 19. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 20. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 21. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 22. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 23. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 24. ? @ 0x00007fbc6213eac3 25. ? @ 0x00007fbc621d0850 2025.07.28 11:50:22.511123 [ 7625 ] {} 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. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x000000000a06b56b 4. /build/src/Processors/QueryPlan/SourceStepWithFilter.cpp:69: DB::SourceStepWithFilter::applyPrewhereActions(DB::Block, std::shared_ptr const&) @ 0x0000000016ea0bf0 5. /build/src/Storages/MergeTree/MergeTreeSelectProcessor.cpp:265: DB::MergeTreeSelectProcessor::transformHeader(DB::Block, std::shared_ptr const&) @ 0x00000000164c05c4 6. /build/src/Processors/QueryPlan/ReadFromMergeTree.cpp:348: 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) @ 0x0000000016e1c7c7 7. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107], 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&) @ 0x0000000016401cd2 8. /build/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 @ 0x00000000163ec114 9. /build/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 @ 0x00000000163ebef8 10. /build/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) @ 0x0000000016635568 11. /build/src/Planner/PlannerJoinTree.cpp:946: DB::(anonymous namespace)::buildQueryPlanForTableExpression(std::shared_ptr, std::shared_ptr const&, DB::SelectQueryInfo const&, DB::SelectQueryOptions const&, std::shared_ptr&, bool, bool) @ 0x00000000149970ee 12. /build/src/Planner/PlannerJoinTree.cpp:2252: DB::buildJoinTreeQueryPlan(std::shared_ptr const&, DB::SelectQueryInfo const&, DB::SelectQueryOptions&, std::unordered_set, std::equal_to, std::allocator> const&, std::shared_ptr&) @ 0x000000001498e109 13. /build/src/Planner/Planner.cpp:1553: DB::Planner::buildPlanForQueryNode() @ 0x0000000014979dae 14. /build/src/Planner/Planner.cpp:1308: DB::Planner::buildQueryPlanIfNeeded() @ 0x000000001497685c 15. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:255: DB::InterpreterSelectQueryAnalyzer::getQueryPlan() @ 0x000000001497476d 16. /build/src/Interpreters/executeQuery.cpp:1405: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88806 17. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 18. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 19. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 20. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 21. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 22. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 23. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 24. ? @ 0x00007fbc6213eac3 25. ? @ 0x00007fbc621d0850 2025.07.28 11:50:22.800346 [ 7630 ] {d3e93544-9f3d-4c69-aff1-b5294c764105} executeQuery: Code: 219. DB::Exception: New table appeared in database being dropped or detached. Try again. (DATABASE_NOT_EMPTY) (version 25.3.6.10636.altinitytest (altinity build)) (from [::1]:60948) (comment: 02473_prewhere_with_bigint.sql) (in query: DROP DATABASE IF EXISTS test_hc99vaqe SYNC ), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000000a074fcb 4. /build/src/Interpreters/DatabaseCatalog.cpp:608: DB::DatabaseCatalog::detachDatabase(std::shared_ptr, String const&, bool, bool) @ 0x00000000144f41b9 5. /build/src/Interpreters/InterpreterDropQuery.cpp:482: DB::InterpreterDropQuery::executeToDatabaseImpl(DB::ASTDropQuery const&, std::shared_ptr&, std::vector, DB::UUIDTag>, std::allocator, DB::UUIDTag>>>&) @ 0x00000000149179be 6. /build/src/Interpreters/InterpreterDropQuery.cpp:363: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x0000000014913988 7. /build/src/Interpreters/InterpreterDropQuery.cpp:99: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000014913142 8. /build/src/Interpreters/InterpreterDropQuery.cpp:72: DB::InterpreterDropQuery::execute() @ 0x0000000014912b65 9. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88dc9 10. /build/src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x0000000014c8ca7b 11. /build/src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000001686da12 12. /build/src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x0000000016870807 13. /build/src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x0000000016907e99 14. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 15. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 16. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 17. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 18. ? @ 0x00007fbc6213eac3 19. ? @ 0x00007fbc621d0850 2025.07.28 11:50:22.808888 [ 7630 ] {d3e93544-9f3d-4c69-aff1-b5294c764105} 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. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000000a074fcb 4. /build/src/Interpreters/DatabaseCatalog.cpp:608: DB::DatabaseCatalog::detachDatabase(std::shared_ptr, String const&, bool, bool) @ 0x00000000144f41b9 5. /build/src/Interpreters/InterpreterDropQuery.cpp:482: DB::InterpreterDropQuery::executeToDatabaseImpl(DB::ASTDropQuery const&, std::shared_ptr&, std::vector, DB::UUIDTag>, std::allocator, DB::UUIDTag>>>&) @ 0x00000000149179be 6. /build/src/Interpreters/InterpreterDropQuery.cpp:363: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x0000000014913988 7. /build/src/Interpreters/InterpreterDropQuery.cpp:99: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000014913142 8. /build/src/Interpreters/InterpreterDropQuery.cpp:72: DB::InterpreterDropQuery::execute() @ 0x0000000014912b65 9. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88dc9 10. /build/src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x0000000014c8ca7b 11. /build/src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000001686da12 12. /build/src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x0000000016870807 13. /build/src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x0000000016907e99 14. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 15. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 16. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 17. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 18. ? @ 0x00007fbc6213eac3 19. ? @ 0x00007fbc621d0850 (version 25.3.6.10636.altinitytest (altinity build)) 2025.07.28 11:50:22.885425 [ 6138 ] {78b2cbaf-5c6e-44fd-8706-a79db0228a1f} executeQuery: Code: 219. DB::Exception: New table appeared in database being dropped or detached. Try again. (DATABASE_NOT_EMPTY) (version 25.3.6.10636.altinitytest (altinity build)) (from [::1]:60958) (comment: 02473_prewhere_with_bigint.sql) (in query: DROP DATABASE IF EXISTS test_hc99vaqe SYNC ), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000000a074fcb 4. /build/src/Interpreters/DatabaseCatalog.cpp:608: DB::DatabaseCatalog::detachDatabase(std::shared_ptr, String const&, bool, bool) @ 0x00000000144f41b9 5. /build/src/Interpreters/InterpreterDropQuery.cpp:482: DB::InterpreterDropQuery::executeToDatabaseImpl(DB::ASTDropQuery const&, std::shared_ptr&, std::vector, DB::UUIDTag>, std::allocator, DB::UUIDTag>>>&) @ 0x00000000149179be 6. /build/src/Interpreters/InterpreterDropQuery.cpp:363: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x0000000014913988 7. /build/src/Interpreters/InterpreterDropQuery.cpp:99: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000014913142 8. /build/src/Interpreters/InterpreterDropQuery.cpp:72: DB::InterpreterDropQuery::execute() @ 0x0000000014912b65 9. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88dc9 10. /build/src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x0000000014c8ca7b 11. /build/src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000001686da12 12. /build/src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x0000000016870807 13. /build/src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x0000000016907e99 14. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 15. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 16. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 17. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 18. ? @ 0x00007fbc6213eac3 19. ? @ 0x00007fbc621d0850 2025.07.28 11:50:22.893401 [ 6138 ] {78b2cbaf-5c6e-44fd-8706-a79db0228a1f} 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. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000000a074fcb 4. /build/src/Interpreters/DatabaseCatalog.cpp:608: DB::DatabaseCatalog::detachDatabase(std::shared_ptr, String const&, bool, bool) @ 0x00000000144f41b9 5. /build/src/Interpreters/InterpreterDropQuery.cpp:482: DB::InterpreterDropQuery::executeToDatabaseImpl(DB::ASTDropQuery const&, std::shared_ptr&, std::vector, DB::UUIDTag>, std::allocator, DB::UUIDTag>>>&) @ 0x00000000149179be 6. /build/src/Interpreters/InterpreterDropQuery.cpp:363: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x0000000014913988 7. /build/src/Interpreters/InterpreterDropQuery.cpp:99: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000014913142 8. /build/src/Interpreters/InterpreterDropQuery.cpp:72: DB::InterpreterDropQuery::execute() @ 0x0000000014912b65 9. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88dc9 10. /build/src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x0000000014c8ca7b 11. /build/src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000001686da12 12. /build/src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x0000000016870807 13. /build/src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x0000000016907e99 14. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 15. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 16. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 17. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 18. ? @ 0x00007fbc6213eac3 19. ? @ 0x00007fbc621d0850 (version 25.3.6.10636.altinitytest (altinity build)) 2025.07.28 11:50:23.689497 [ 4900 ] {1bce31fc-a9e9-4e07-9c27-b1b42d9981cd} executeQuery: Code: 43. DB::Exception: Illegal type AggregateFunction(min, UInt8) of argument for aggregate function groupBitmapAnd. (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.6.10636.altinitytest (altinity build)) (from [::1]:60212) (comment: 02429_groupBitmap_chain_state.sql) (query 3, line 4) (in query: SELECT groupBitmapAnd(z) FROM ( SELECT minState(u) AS z FROM ( SELECT 123 AS u ) AS a1 ) AS a2;), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String const&) @ 0x000000000a68756b 4. /build/src/AggregateFunctions/AggregateFunctionGroupBitmap.cpp:259: std::shared_ptr DB::(anonymous namespace)::createAggregateFunctionBitmapL2(String const&, std::vector, std::allocator>> const&, DB::Array const&, DB::Settings const*) @ 0x000000001147d165 5. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000131e00dd 6. /build/src/AggregateFunctions/AggregateFunctionFactory.cpp:130: DB::AggregateFunctionFactory::get(String const&, DB::NullsAction, std::vector, std::allocator>> const&, DB::Array const&, DB::AggregateFunctionProperties&) const @ 0x00000000131df0ca 7. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3368: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000014032fed 8. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3838: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000014019a9e 9. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3980: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000014018e31 10. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:4304: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000014042fa7 11. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5605: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000014013749 12. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000140127f9 13. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000014011fce 14. /build/src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000001406ce8a 15. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000014973b42 16. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000001497268d 17. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000014974d24 18. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001492924b 19. /build/src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88641 20. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 21. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 22. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 23. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 24. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 25. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 26. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 27. ? @ 0x00007fbc6213eac3 28. ? @ 0x00007fbc621d0850 2025.07.28 11:50:23.694897 [ 4900 ] {} TCPHandler: Code: 43. DB::Exception: Illegal type AggregateFunction(min, UInt8) of argument for aggregate function groupBitmapAnd. (ILLEGAL_TYPE_OF_ARGUMENT), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String const&) @ 0x000000000a68756b 4. /build/src/AggregateFunctions/AggregateFunctionGroupBitmap.cpp:259: std::shared_ptr DB::(anonymous namespace)::createAggregateFunctionBitmapL2(String const&, std::vector, std::allocator>> const&, DB::Array const&, DB::Settings const*) @ 0x000000001147d165 5. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000131e00dd 6. /build/src/AggregateFunctions/AggregateFunctionFactory.cpp:130: DB::AggregateFunctionFactory::get(String const&, DB::NullsAction, std::vector, std::allocator>> const&, DB::Array const&, DB::AggregateFunctionProperties&) const @ 0x00000000131df0ca 7. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3368: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000014032fed 8. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3838: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000014019a9e 9. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3980: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000014018e31 10. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:4304: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000014042fa7 11. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5605: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000014013749 12. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000140127f9 13. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000014011fce 14. /build/src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000001406ce8a 15. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000014973b42 16. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000001497268d 17. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000014974d24 18. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001492924b 19. /build/src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88641 20. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 21. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 22. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 23. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 24. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 25. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 26. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 27. ? @ 0x00007fbc6213eac3 28. ? @ 0x00007fbc621d0850 2025.07.28 11:50:23.872182 [ 4900 ] {40bd8523-df60-49c5-b718-6ffaf5c87dcd} executeQuery: Code: 43. DB::Exception: Illegal type AggregateFunction(max, String) of argument for aggregate function groupBitmapOr. (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.6.10636.altinitytest (altinity build)) (from [::1]:60212) (comment: 02429_groupBitmap_chain_state.sql) (query 4, line 5) (in query: SELECT groupBitmapOr(z) FROM ( SELECT maxState(u) AS z FROM ( SELECT '123' AS u ) AS a1 ) AS a2;), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String const&) @ 0x000000000a68756b 4. /build/src/AggregateFunctions/AggregateFunctionGroupBitmap.cpp:259: std::shared_ptr DB::(anonymous namespace)::createAggregateFunctionBitmapL2(String const&, std::vector, std::allocator>> const&, DB::Array const&, DB::Settings const*) @ 0x000000001147ee85 5. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000131e00dd 6. /build/src/AggregateFunctions/AggregateFunctionFactory.cpp:130: DB::AggregateFunctionFactory::get(String const&, DB::NullsAction, std::vector, std::allocator>> const&, DB::Array const&, DB::AggregateFunctionProperties&) const @ 0x00000000131df0ca 7. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3368: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000014032fed 8. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3838: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000014019a9e 9. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3980: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000014018e31 10. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:4304: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000014042fa7 11. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5605: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000014013749 12. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000140127f9 13. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000014011fce 14. /build/src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000001406ce8a 15. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000014973b42 16. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000001497268d 17. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000014974d24 18. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001492924b 19. /build/src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88641 20. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 21. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 22. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 23. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 24. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 25. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 26. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 27. ? @ 0x00007fbc6213eac3 28. ? @ 0x00007fbc621d0850 2025.07.28 11:50:23.886436 [ 4900 ] {} TCPHandler: Code: 43. DB::Exception: Illegal type AggregateFunction(max, String) of argument for aggregate function groupBitmapOr. (ILLEGAL_TYPE_OF_ARGUMENT), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String const&) @ 0x000000000a68756b 4. /build/src/AggregateFunctions/AggregateFunctionGroupBitmap.cpp:259: std::shared_ptr DB::(anonymous namespace)::createAggregateFunctionBitmapL2(String const&, std::vector, std::allocator>> const&, DB::Array const&, DB::Settings const*) @ 0x000000001147ee85 5. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000131e00dd 6. /build/src/AggregateFunctions/AggregateFunctionFactory.cpp:130: DB::AggregateFunctionFactory::get(String const&, DB::NullsAction, std::vector, std::allocator>> const&, DB::Array const&, DB::AggregateFunctionProperties&) const @ 0x00000000131df0ca 7. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3368: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000014032fed 8. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3838: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000014019a9e 9. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3980: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000014018e31 10. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:4304: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000014042fa7 11. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5605: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000014013749 12. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000140127f9 13. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000014011fce 14. /build/src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000001406ce8a 15. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000014973b42 16. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000001497268d 17. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000014974d24 18. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001492924b 19. /build/src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88641 20. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 21. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 22. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 23. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 24. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 25. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 26. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 27. ? @ 0x00007fbc6213eac3 28. ? @ 0x00007fbc621d0850 2025.07.28 11:50:24.043518 [ 4900 ] {e5d6e2a7-9d1e-45ca-8f9a-8842353ad5de} executeQuery: Code: 43. DB::Exception: Illegal type AggregateFunction(count) of argument for aggregate function groupBitmapXor. (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.6.10636.altinitytest (altinity build)) (from [::1]:60212) (comment: 02429_groupBitmap_chain_state.sql) (query 5, line 6) (in query: SELECT groupBitmapXor(z) FROM ( SELECT countState() AS z FROM ( SELECT '123' AS u ) AS a1 ) AS a2;), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String const&) @ 0x000000000a68756b 4. /build/src/AggregateFunctions/AggregateFunctionGroupBitmap.cpp:259: std::shared_ptr DB::(anonymous namespace)::createAggregateFunctionBitmapL2(String const&, std::vector, std::allocator>> const&, DB::Array const&, DB::Settings const*) @ 0x0000000011480ba5 5. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000131e00dd 6. /build/src/AggregateFunctions/AggregateFunctionFactory.cpp:130: DB::AggregateFunctionFactory::get(String const&, DB::NullsAction, std::vector, std::allocator>> const&, DB::Array const&, DB::AggregateFunctionProperties&) const @ 0x00000000131df0ca 7. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3368: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000014032fed 8. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3838: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000014019a9e 9. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3980: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000014018e31 10. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:4304: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000014042fa7 11. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5605: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000014013749 12. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000140127f9 13. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000014011fce 14. /build/src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000001406ce8a 15. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000014973b42 16. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000001497268d 17. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000014974d24 18. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001492924b 19. /build/src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88641 20. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 21. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 22. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 23. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 24. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 25. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 26. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 27. ? @ 0x00007fbc6213eac3 28. ? @ 0x00007fbc621d0850 2025.07.28 11:50:24.051802 [ 4900 ] {} TCPHandler: Code: 43. DB::Exception: Illegal type AggregateFunction(count) of argument for aggregate function groupBitmapXor. (ILLEGAL_TYPE_OF_ARGUMENT), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String const&) @ 0x000000000a68756b 4. /build/src/AggregateFunctions/AggregateFunctionGroupBitmap.cpp:259: std::shared_ptr DB::(anonymous namespace)::createAggregateFunctionBitmapL2(String const&, std::vector, std::allocator>> const&, DB::Array const&, DB::Settings const*) @ 0x0000000011480ba5 5. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000131e00dd 6. /build/src/AggregateFunctions/AggregateFunctionFactory.cpp:130: DB::AggregateFunctionFactory::get(String const&, DB::NullsAction, std::vector, std::allocator>> const&, DB::Array const&, DB::AggregateFunctionProperties&) const @ 0x00000000131df0ca 7. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3368: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000014032fed 8. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3838: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000014019a9e 9. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3980: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000014018e31 10. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:4304: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000014042fa7 11. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5605: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000014013749 12. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000140127f9 13. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000014011fce 14. /build/src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000001406ce8a 15. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000014973b42 16. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000001497268d 17. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000014974d24 18. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001492924b 19. /build/src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88641 20. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 21. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 22. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 23. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 24. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 25. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 26. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 27. ? @ 0x00007fbc6213eac3 28. ? @ 0x00007fbc621d0850 2025.07.28 11:50:27.363052 [ 7625 ] {fa57bd4b-6abb-4885-b07b-3e6cffdf8cb0} executeQuery: Code: 159. DB::Exception: Timeout exceeded: elapsed 1140.405407 ms, maximum: 1100 ms. (TIMEOUT_EXCEEDED) (version 25.3.6.10636.altinitytest (altinity build)) (from [::1]:60544) (comment: 02294_floating_point_second_in_settings.sh) (query 1, line 1) (in query: SELECT count() FROM system.numbers), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&, unsigned long const&) @ 0x000000001451e16b 4. /build/src/Interpreters/ProcessList.cpp:519: DB::QueryStatus::throwProperExceptionIfNeeded(unsigned long const&, unsigned long const&) @ 0x0000000014a4bbbb 5. /build/src/Interpreters/ProcessList.cpp:557: DB::QueryStatus::checkTimeLimit() @ 0x0000000014a4c2cd 6. /build/src/Processors/Executors/PipelineExecutor.cpp:206: DB::PipelineExecutor::finalizeExecution() @ 0x00000000169b13ba 7. /build/src/Processors/Executors/PipelineExecutor.cpp:153: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x00000000169b0584 8. /build/src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:se190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169bfeab 9. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc3d92 10. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fcca080 11. ? @ 0x00007fbc6213eac3 12. ? @ 0x00007fbc621d0850 2025.07.28 11:50:27.383872 [ 7625 ] {} TCPHandler: Code: 159. DB::Exception: Timeout exceeded: elapsed 1140.405407 ms, maximum: 1100 ms. (TIMEOUT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&, unsigned long const&) @ 0x000000001451e16b 4. /build/src/Interpreters/ProcessList.cpp:519: DB::QueryStatus::throwProperExceptionIfNeeded(unsigned long const&, unsigned long const&) @ 0x0000000014a4bbbb 5. /build/src/Interpreters/ProcessList.cpp:557: DB::QueryStatus::checkTimeLimit() @ 0x0000000014a4c2cd 6. /build/src/Processors/Executors/PipelineExecutor.cpp:206: DB::PipelineExecutor::finalizeExecution() @ 0x00000000169b13ba 7. /build/src/Processors/Executors/PipelineExecutor.cpp:153: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x00000000169b0584 8. /build/src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:se190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169bfeab 9. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc3d92 10. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fcca080 11. ? @ 0x00007fbc6213eac3 12. ? @ 0x00007fbc621d0850 Job's origin stack trace: 0. /build/src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000000fc33b84 1. /build/src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000000fcc2ea7 2. /build/src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fcc535c 3. /build/src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000000fcc584d 4. /build/src/Common/ThreadPool.h:279: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x00000000169bf193 5. /build/src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x00000000169bf518 6. /build/src/Server/TCPHandler.cpp:1237: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x00000000168f1525 7. /build/src/Server/TCPHandler.cpp:678: DB::TCPHandler::runImpl() @ 0x00000000168e68e5 8. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 9. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 10. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 11. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 12. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 13. ? @ 0x00007fbc6213eac3 14. ? @ 0x00007fbc621d0850 2025.07.28 11:50:28.445343 [ 4508 ] {4b266867-c62a-4e2d-85a6-e48028fef4eb} executeQuery: Code: 47. DB::Exception: Missing columns: 'x' while processing: 'SELECT x = 1, id FROM test_1.replicated_table_r1', required columns: 'id' 'x', maybe you meant: 'id': While applying a row policy (see system.row_policies). (UNKNOWN_IDENTIFIER) (version 25.3.6.10636.altinitytest (altinity build)) (from [::1]:60502) (comment: 02352_lightweight_delete_on_replicated_merge_tree.sql) (query 7, line 13) (in query: DELETE FROM replicated_table_r1 WHERE id = 10;), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Interpreters/TreeRewriter.cpp:1303: DB::TreeRewriterResult::collectUsedColumns(std::shared_ptr const&, bool, bool) @ 0x0000000014c01fc8 4. /build/src/Interpreters/TreeRewriter.cpp:1448: DB::TreeRewriter::analyzeSelect(std::shared_ptr&, DB::TreeRewriterResult&&, DB::SelectQueryOptions const&, std::vector> const&, std::vector> const&, std::shared_ptr) const @ 0x0000000014c05792 5. /build/src/Interpreters/InterpreterSelectQuery.cpp:272: DB::generateFilterActions(DB::StorageID const&, std::shared_ptr const&, std::shared_ptr const&, std::shared_ptr const&, std::shared_ptr const&, std::shared_ptr const&, std::vector>&, std::shared_ptr) @ 0x000000001493f7f3 6. /build/src/Interpreters/InterpreterSelectQuery.cpp:888: 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 @ 0x0000000014948aa5 7. /build/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) @ 0x0000000014943f47 8. /build/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) @ 0x000000001494088c 9. /build/src/Interpreters/InterpreterSelectQuery.cpp:328: DB::InterpreterSelectQuery::InterpreterSelectQuery(std::shared_ptr const&, std::shared_ptr const&, std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000014946974 10. /build/src/Interpreters/MutationsInterpreter.cpp:1441: DB::MutationsInterpreter::validate() @ 0x0000000014a3191c 11. /build/src/Interpreters/InterpreterAlterQuery.cpp:235: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x00000000148deddb 12. /build/src/Interpreters/InterpreterAlterQuery.cpp:77: DB::InterpreterAlterQuery::execute() @ 0x00000000148dcb0d 13. /build/src/Interpreters/InterpreterDeleteQuery.cpp:140: DB::InterpreterDeleteQuery::execute() @ 0x0000000014d00a0d 14. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88dc9 15. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 16. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 17. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 18. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 19. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 20. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 21. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 22. ? @ 0x00007fbc6213eac3 23. ? @ 0x00007fbc621d0850 2025.07.28 11:50:28.458483 [ 4508 ] {} TCPHandler: Code: 47. DB::Exception: Missing columns: 'x' while processing: 'SELECT x = 1, id FROM test_1.replicated_table_r1', required columns: 'id' 'x', maybe you meant: 'id': While applying a row policy (see system.row_policies). (UNKNOWN_IDENTIFIER), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Interpreters/TreeRewriter.cpp:1303: DB::TreeRewriterResult::collectUsedColumns(std::shared_ptr const&, bool, bool) @ 0x0000000014c01fc8 4. /build/src/Interpreters/TreeRewriter.cpp:1448: DB::TreeRewriter::analyzeSelect(std::shared_ptr&, DB::TreeRewriterResult&&, DB::SelectQueryOptions const&, std::vector> const&, std::vector> const&, std::shared_ptr) const @ 0x0000000014c05792 5. /build/src/Interpreters/InterpreterSelectQuery.cpp:272: DB::generateFilterActions(DB::StorageID const&, std::shared_ptr const&, std::shared_ptr const&, std::shared_ptr const&, std::shared_ptr const&, std::shared_ptr const&, std::vector>&, std::shared_ptr) @ 0x000000001493f7f3 6. /build/src/Interpreters/InterpreterSelectQuery.cpp:888: 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 @ 0x0000000014948aa5 7. /build/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) @ 0x0000000014943f47 8. /build/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) @ 0x000000001494088c 9. /build/src/Interpreters/InterpreterSelectQuery.cpp:328: DB::InterpreterSelectQuery::InterpreterSelectQuery(std::shared_ptr const&, std::shared_ptr const&, std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000014946974 10. /build/src/Interpreters/MutationsInterpreter.cpp:1441: DB::MutationsInterpreter::validate() @ 0x0000000014a3191c 11. /build/src/Interpreters/InterpreterAlterQuery.cpp:235: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x00000000148deddb 12. /build/src/Interpreters/InterpreterAlterQuery.cpp:77: DB::InterpreterAlterQuery::execute() @ 0x00000000148dcb0d 13. /build/src/Interpreters/InterpreterDeleteQuery.cpp:140: DB::InterpreterDeleteQuery::execute() @ 0x0000000014d00a0d 14. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88dc9 15. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 16. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 17. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 18. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 19. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 20. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 21. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 22. ? @ 0x00007fbc6213eac3 23. ? @ 0x00007fbc621d0850 2025.07.28 11:50:28.687618 [ 4587 ] {08192a17-5e7c-44cb-b9e1-6230054cdfea} executeQuery: Code: 159. DB::Exception: Timeout exceeded: elapsed 1108.518277 ms, maximum: 1100 ms. (TIMEOUT_EXCEEDED) (version 25.3.6.10636.altinitytest (altinity build)) (from [::1]:60620) (comment: 02294_floating_point_second_in_settings.sh) (query 1, line 1) (in query: SELECT count() FROM system.numbers SETTINGS max_execution_time=1.100), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, double&&, long&&) @ 0x0000000013bb358b 4. /build/src/QueryPipeline/ExecutionSpeedLimits.cpp:113: DB::ExecutionSpeedLimits::checkTimeLimit(unsigned long const&, DB::OverflowMode) const @ 0x0000000013bb28cc 5. /build/src/Interpreters/ProcessList.cpp:559: DB::QueryStatus::checkTimeLimit() @ 0x0000000014a4c2df 6. /build/src/Processors/Executors/PipelineExecutor.cpp:206: DB::PipelineExecutor::finalizeExecution() @ 0x00000000169b13ba 7. /build/src/Processors/Executors/PipelineExecutor.cpp:153: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x00000000169b0584 8. /build/src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:se190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169bfeab 9. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc3d92 10. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fcca080 11. ? @ 0x00007fbc6213eac3 12. ? @ 0x00007fbc621d0850 2025.07.28 11:50:28.790750 [ 4587 ] {} TCPHandler: Code: 159. DB::Exception: Timeout exceeded: elapsed 1108.518277 ms, maximum: 1100 ms. (TIMEOUT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, double&&, long&&) @ 0x0000000013bb358b 4. /build/src/QueryPipeline/ExecutionSpeedLimits.cpp:113: DB::ExecutionSpeedLimits::checkTimeLimit(unsigned long const&, DB::OverflowMode) const @ 0x0000000013bb28cc 5. /build/src/Interpreters/ProcessList.cpp:559: DB::QueryStatus::checkTimeLimit() @ 0x0000000014a4c2df 6. /build/src/Processors/Executors/PipelineExecutor.cpp:206: DB::PipelineExecutor::finalizeExecution() @ 0x00000000169b13ba 7. /build/src/Processors/Executors/PipelineExecutor.cpp:153: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x00000000169b0584 8. /build/src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:se190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169bfeab 9. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc3d92 10. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fcca080 11. ? @ 0x00007fbc6213eac3 12. ? @ 0x00007fbc621d0850 Job's origin stack trace: 0. /build/src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000000fc33b84 1. /build/src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000000fcc2ea7 2. /build/src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fcc535c 3. /build/src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000000fcc584d 4. /build/src/Common/ThreadPool.h:279: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x00000000169bf193 5. /build/src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x00000000169bf518 6. /build/src/Server/TCPHandler.cpp:1237: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x00000000168f1525 7. /build/src/Server/TCPHandler.cpp:678: DB::TCPHandler::runImpl() @ 0x00000000168e68e5 8. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 9. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 10. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 11. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 12. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 13. ? @ 0x00007fbc6213eac3 14. ? @ 0x00007fbc621d0850 2025.07.28 11:50:28.808461 [ 5980 ] {1b761975-e182-4108-860d-9791edcc6ff5} executeQuery: Code: 36. DB::Exception: Invalid time zone: Ðбырвалг. (BAD_ARGUMENTS) (version 25.3.6.10636.altinitytest (altinity build)) (from [::1]:60718) (comment: 02737_session_timezone.sql) (query 1, line 1) (in query: SET session_timezone = 'Ðбырвалг';), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000a9b78ab 4. /build/src/Core/SettingsFields.cpp:519: DB::SettingFieldTimezone::validateTimezone(String const&) @ 0x0000000013b8c423 5. /build/src/Core/SettingsFields.h:507: DB::SettingFieldTimezone::SettingFieldTimezone(DB::Field const&) @ 0x0000000013b10027 6. /build/src/Core/Settings.cpp:6219: DB::SettingsTraits::Accessor::instance()::$_0::operator()() const::'lambda1657'(DB::Field const&)::__invoke(DB::Field const&) @ 0x0000000013acc297 7. /build/src/Core/Settings.cpp:6218: DB::BaseSettings::castValueUtil(std::basic_string_view>, DB::Field const&) @ 0x0000000013b07122 8. /build/src/Core/Settings.cpp:6661: DB::Settings::castValueUtil(std::basic_string_view>, DB::Field const&) @ 0x0000000013a58cc9 9. /build/src/Access/SettingsConstraints.cpp:245: bool DB::getNewValueToCheck(DB::Settings const&, DB::SettingChange&, DB::Field&, bool) @ 0x000000001385a1ab 10. /build/src/Access/SettingsConstraints.cpp:297: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000013858f7b 11. /build/src/Access/SettingsConstraints.cpp:194: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges const&, DB::SettingSource) const @ 0x00000000138591b3 12. /build/src/Interpreters/Context.cpp:2722: DB::Context::checkSettingsConstraints(DB::SettingsChanges const&, DB::SettingSource) @ 0x0000000014436509 13. /build/src/Interpreters/InterpreterSetQuery.cpp:28: DB::InterpreterSetQuery::execute() @ 0x00000000149e240a 14. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88dc9 15. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 16. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 17. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 18. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 19. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 20. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 21. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 22. ? @ 0x00007fbc6213eac3 23. ? @ 0x00007fbc621d0850 2025.07.28 11:50:28.833090 [ 5980 ] {} TCPHandler: Code: 36. DB::Exception: Invalid time zone: Ðбырвалг. (BAD_ARGUMENTS), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000a9b78ab 4. /build/src/Core/SettingsFields.cpp:519: DB::SettingFieldTimezone::validateTimezone(String const&) @ 0x0000000013b8c423 5. /build/src/Core/SettingsFields.h:507: DB::SettingFieldTimezone::SettingFieldTimezone(DB::Field const&) @ 0x0000000013b10027 6. /build/src/Core/Settings.cpp:6219: DB::SettingsTraits::Accessor::instance()::$_0::operator()() const::'lambda1657'(DB::Field const&)::__invoke(DB::Field const&) @ 0x0000000013acc297 7. /build/src/Core/Settings.cpp:6218: DB::BaseSettings::castValueUtil(std::basic_string_view>, DB::Field const&) @ 0x0000000013b07122 8. /build/src/Core/Settings.cpp:6661: DB::Settings::castValueUtil(std::basic_string_view>, DB::Field const&) @ 0x0000000013a58cc9 9. /build/src/Access/SettingsConstraints.cpp:245: bool DB::getNewValueToCheck(DB::Settings const&, DB::SettingChange&, DB::Field&, bool) @ 0x000000001385a1ab 10. /build/src/Access/SettingsConstraints.cpp:297: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000013858f7b 11. /build/src/Access/SettingsConstraints.cpp:194: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges const&, DB::SettingSource) const @ 0x00000000138591b3 12. /build/src/Interpreters/Context.cpp:2722: DB::Context::checkSettingsConstraints(DB::SettingsChanges const&, DB::SettingSource) @ 0x0000000014436509 13. /build/src/Interpreters/InterpreterSetQuery.cpp:28: DB::InterpreterSetQuery::execute() @ 0x00000000149e240a 14. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88dc9 15. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 16. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 17. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 18. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 19. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 20. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 21. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 22. ? @ 0x00007fbc6213eac3 23. ? @ 0x00007fbc621d0850 2025.07.28 11:50:29.839811 [ 7630 ] {7d952ab3-5f8e-46fb-907f-8ca7e14c6c2f} executeQuery: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION) (version 25.3.6.10636.altinitytest (altinity build)) (from [::1]:60828) (comment: 03254_limit_by_with_offset_parallel_replicas.sh) (query 1, line 2) (in query: set enable_analyzer=0;), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x000000000c25bc4b 4. /build/src/Access/SettingsConstraints.cpp:343: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000138596e3 5. /build/src/Access/SettingsConstraints.cpp:300: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000013858faf 6. /build/src/Access/SettingsConstraints.cpp:194: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges const&, DB::SettingSource) const @ 0x00000000138591b3 7. /build/src/Interpreters/Context.cpp:2722: DB::Context::checkSettingsConstraints(DB::SettingsChanges const&, DB::SettingSource) @ 0x0000000014436509 8. /build/src/Interpreters/InterpreterSetQuery.cpp:28: DB::InterpreterSetQuery::execute() @ 0x00000000149e240a 9. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88dc9 10. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 11. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 12. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 13. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 14. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 16. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 17. ? @ 0x00007fbc6213eac3 18. ? @ 0x00007fbc621d0850 2025.07.28 11:50:29.859126 [ 7630 ] {} 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. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x000000000c25bc4b 4. /build/src/Access/SettingsConstraints.cpp:343: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000138596e3 5. /build/src/Access/SettingsConstraints.cpp:300: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000013858faf 6. /build/src/Access/SettingsConstraints.cpp:194: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges const&, DB::SettingSource) const @ 0x00000000138591b3 7. /build/src/Interpreters/Context.cpp:2722: DB::Context::checkSettingsConstraints(DB::SettingsChanges const&, DB::SettingSource) @ 0x0000000014436509 8. /build/src/Interpreters/InterpreterSetQuery.cpp:28: DB::InterpreterSetQuery::execute() @ 0x00000000149e240a 9. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88dc9 10. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 11. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 12. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 13. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 14. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 16. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 17. ? @ 0x00007fbc6213eac3 18. ? @ 0x00007fbc621d0850 2025.07.28 11:50:29.980938 [ 4508 ] {ed6882e9-b5f8-4e1d-98cd-05301b16bd3a} executeQuery: Code: 159. DB::Exception: Timeout exceeded: elapsed 1107.929688 ms, maximum: 1100 ms. (TIMEOUT_EXCEEDED) (version 25.3.6.10636.altinitytest (altinity build)) (from [::ffff:127.0.0.1]:57756) (comment: 02294_floating_point_second_in_settings.sh) (in query: SELECT count() FROM system.numbers), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&, unsigned long const&) @ 0x000000001451e16b 4. /build/src/Interpreters/ProcessList.cpp:519: DB::QueryStatus::throwProperExceptionIfNeeded(unsigned long const&, unsigned long const&) @ 0x0000000014a4bbbb 5. /build/src/Interpreters/ProcessList.cpp:557: DB::QueryStatus::checkTimeLimit() @ 0x0000000014a4c2cd 6. /build/src/Processors/Executors/PipelineExecutor.cpp:206: DB::PipelineExecutor::finalizeExecution() @ 0x00000000169b13ba 7. /build/src/Processors/Executors/PipelineExecutor.cpp:153: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x00000000169b0584 8. /build/src/Processors/Executors/CompletedPipelineExecutor.cpp:105: DB::CompletedPipelineExecutor::execute() @ 0x00000000169af3c4 9. /build/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&)>) @ 0x0000000014c8d123 10. /build/src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000001686da12 11. /build/src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x0000000016870807 12. /build/src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x0000000016907e99 13. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 14. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 16. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 17. ? @ 0x00007fbc6213eac3 18. ? @ 0x00007fbc621d0850 2025.07.28 11:50:29.983735 [ 4508 ] {ed6882e9-b5f8-4e1d-98cd-05301b16bd3a} DynamicQueryHandler: Code: 159. DB::Exception: Timeout exceeded: elapsed 1107.929688 ms, maximum: 1100 ms. (TIMEOUT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&, unsigned long const&) @ 0x000000001451e16b 4. /build/src/Interpreters/ProcessList.cpp:519: DB::QueryStatus::throwProperExceptionIfNeeded(unsigned long const&, unsigned long const&) @ 0x0000000014a4bbbb 5. /build/src/Interpreters/ProcessList.cpp:557: DB::QueryStatus::checkTimeLimit() @ 0x0000000014a4c2cd 6. /build/src/Processors/Executors/PipelineExecutor.cpp:206: DB::PipelineExecutor::finalizeExecution() @ 0x00000000169b13ba 7. /build/src/Processors/Executors/PipelineExecutor.cpp:153: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x00000000169b0584 8. /build/src/Processors/Executors/CompletedPipelineExecutor.cpp:105: DB::CompletedPipelineExecutor::execute() @ 0x00000000169af3c4 9. /build/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&)>) @ 0x0000000014c8d123 10. /build/src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000001686da12 11. /build/src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x0000000016870807 12. /build/src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x0000000016907e99 13. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 14. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 16. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 17. ? @ 0x00007fbc6213eac3 18. ? @ 0x00007fbc621d0850 (version 25.3.6.10636.altinitytest (altinity build)) 2025.07.28 11:50:30.092695 [ 4749 ] {95ea0d72-0826-48ca-a3a4-0e3b3e64ff77} executeQuery: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION) (version 25.3.6.10636.altinitytest (altinity build)) (from [::1]:60912) (comment: 03254_limit_by_with_offset_parallel_replicas.sh) (query 1, line 2) (in query: set enable_analyzer=0;), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x000000000c25bc4b 4. /build/src/Access/SettingsConstraints.cpp:343: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000138596e3 5. /build/src/Access/SettingsConstraints.cpp:300: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000013858faf 6. /build/src/Access/SettingsConstraints.cpp:194: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges const&, DB::SettingSource) const @ 0x00000000138591b3 7. /build/src/Interpreters/Context.cpp:2722: DB::Context::checkSettingsConstraints(DB::SettingsChanges const&, DB::SettingSource) @ 0x0000000014436509 8. /build/src/Interpreters/InterpreterSetQuery.cpp:28: DB::InterpreterSetQuery::execute() @ 0x00000000149e240a 9. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88dc9 10. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 11. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 12. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 13. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 14. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 16. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 17. ? @ 0x00007fbc6213eac3 18. ? @ 0x00007fbc621d0850 2025.07.28 11:50:30.100754 [ 4749 ] {} 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. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x000000000c25bc4b 4. /build/src/Access/SettingsConstraints.cpp:343: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000138596e3 5. /build/src/Access/SettingsConstraints.cpp:300: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000013858faf 6. /build/src/Access/SettingsConstraints.cpp:194: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges const&, DB::SettingSource) const @ 0x00000000138591b3 7. /build/src/Interpreters/Context.cpp:2722: DB::Context::checkSettingsConstraints(DB::SettingsChanges const&, DB::SettingSource) @ 0x0000000014436509 8. /build/src/Interpreters/InterpreterSetQuery.cpp:28: DB::InterpreterSetQuery::execute() @ 0x00000000149e240a 9. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88dc9 10. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 11. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 12. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 13. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 14. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 16. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 17. ? @ 0x00007fbc6213eac3 18. ? @ 0x00007fbc621d0850 2025.07.28 11:50:31.130150 [ 4508 ] {71cd8470-0688-4ad8-ac60-fc9244f3be03} executeQuery: Code: 36. DB::Exception: Argument 'ttl' must be a literal, get Identifier_k (value: k). (BAD_ARGUMENTS) (version 25.3.6.10636.altinitytest (altinity build)) (from [::1]:32800) (comment: 02811_invalid_embedded_rocksdb_create.sql) (query 1, line 2) (in query: CREATE TABLE dict (`k` String, `v` String) ENGINE = EmbeddedRocksDB(k) PRIMARY KEY k;), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, String&&, String&&) @ 0x000000001098ed2b 4. /build/src/Storages/checkAndGetLiteralArgument.cpp:25: unsigned long DB::checkAndGetLiteralArgument(std::shared_ptr const&, String const&) @ 0x0000000016052399 5. /build/src/Storages/RocksDB/StorageEmbeddedRocksDB.cpp:697: DB::create(DB::StorageFactory::Arguments const&) @ 0x0000000013462f17 6. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000015d81ea2 7. /build/src/Interpreters/InterpreterCreateQuery.cpp:1945: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x00000000149009bb 8. /build/src/Interpreters/InterpreterCreateQuery.cpp:1743: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000148f9aa9 9. /build/src/Interpreters/InterpreterCreateQuery.cpp:2352: DB::InterpreterCreateQuery::execute() @ 0x0000000014905a41 10. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88dc9 11. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 12. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 13. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 14. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 15. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 16. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 17. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 18. ? @ 0x00007fbc6213eac3 19. ? @ 0x00007fbc621d0850 2025.07.28 11:50:31.152313 [ 4508 ] {} TCPHandler: Code: 36. DB::Exception: Argument 'ttl' must be a literal, get Identifier_k (value: k). (BAD_ARGUMENTS), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, String&&, String&&) @ 0x000000001098ed2b 4. /build/src/Storages/checkAndGetLiteralArgument.cpp:25: unsigned long DB::checkAndGetLiteralArgument(std::shared_ptr const&, String const&) @ 0x0000000016052399 5. /build/src/Storages/RocksDB/StorageEmbeddedRocksDB.cpp:697: DB::create(DB::StorageFactory::Arguments const&) @ 0x0000000013462f17 6. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000015d81ea2 7. /build/src/Interpreters/InterpreterCreateQuery.cpp:1945: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x00000000149009bb 8. /build/src/Interpreters/InterpreterCreateQuery.cpp:1743: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000148f9aa9 9. /build/src/Interpreters/InterpreterCreateQuery.cpp:2352: DB::InterpreterCreateQuery::execute() @ 0x0000000014905a41 10. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88dc9 11. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 12. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 13. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 14. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 15. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 16. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 17. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 18. ? @ 0x00007fbc6213eac3 19. ? @ 0x00007fbc621d0850 2025.07.28 11:50:31.430279 [ 5980 ] {27eb19eb-b151-471f-9436-d89ce8d3198d} executeQuery: Code: 47. DB::Exception: Unknown expression or function identifier `x` in scope x = 1. Maybe you meant: ['d']. (UNKNOWN_IDENTIFIER) (version 25.3.6.10636.altinitytest (altinity build)) (from [::1]:60718) (comment: 02737_session_timezone.sql) (query 13, line 24) (in query: -- Test parsing in WHERE filter, shall have the same logic as insert SELECT d FROM test_tz_setting WHERE d == '2000-01-01 01:00:00';), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.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&&) @ 0x000000001404b3b9 4. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3771: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000001401b849 5. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3980: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000014018e31 6. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:2925: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000001402fcbd 7. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3838: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000014019a9e 8. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:209: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000001401270e 9. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000014011fce 10. /build/src/Planner/Utils.cpp:458: DB::buildFilterInfo(std::shared_ptr, std::shared_ptr const&, std::shared_ptr&, std::unordered_set, std::equal_to, std::allocator>) @ 0x0000000013fe8bcf 11. /build/src/Planner/PlannerJoinTree.cpp:535: DB::(anonymous namespace)::buildQueryPlanForTableExpression(std::shared_ptr, std::shared_ptr const&, DB::SelectQueryInfo const&, DB::SelectQueryOptions const&, std::shared_ptr&, bool, bool) @ 0x00000000149956d3 12. /build/src/Planner/PlannerJoinTree.cpp:2252: DB::buildJoinTreeQueryPlan(std::shared_ptr const&, DB::SelectQueryInfo const&, DB::SelectQueryOptions&, std::unordered_set, std::equal_to, std::allocator> const&, std::shared_ptr&) @ 0x000000001498e109 13. /build/src/Planner/Planner.cpp:1553: DB::Planner::buildPlanForQueryNode() @ 0x0000000014979dae 14. /build/src/Planner/Planner.cpp:1308: DB::Planner::buildQueryPlanIfNeeded() @ 0x000000001497685c 15. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:255: DB::InterpreterSelectQueryAnalyzer::getQueryPlan() @ 0x000000001497476d 16. /build/src/Interpreters/executeQuery.cpp:1405: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88806 17. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 18. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 19. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 20. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 21. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 22. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 23. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 24. ? @ 0x00007fbc6213eac3 25. ? @ 0x00007fbc621d0850 2025.07.28 11:50:31.460143 [ 5980 ] {} TCPHandler: Code: 47. DB::Exception: Unknown expression or function identifier `x` in scope x = 1. Maybe you meant: ['d']. (UNKNOWN_IDENTIFIER), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.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&&) @ 0x000000001404b3b9 4. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3771: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000001401b849 5. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3980: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000014018e31 6. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:2925: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000001402fcbd 7. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3838: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000014019a9e 8. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:209: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000001401270e 9. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000014011fce 10. /build/src/Planner/Utils.cpp:458: DB::buildFilterInfo(std::shared_ptr, std::shared_ptr const&, std::shared_ptr&, std::unordered_set, std::equal_to, std::allocator>) @ 0x0000000013fe8bcf 11. /build/src/Planner/PlannerJoinTree.cpp:535: DB::(anonymous namespace)::buildQueryPlanForTableExpression(std::shared_ptr, std::shared_ptr const&, DB::SelectQueryInfo const&, DB::SelectQueryOptions const&, std::shared_ptr&, bool, bool) @ 0x00000000149956d3 12. /build/src/Planner/PlannerJoinTree.cpp:2252: DB::buildJoinTreeQueryPlan(std::shared_ptr const&, DB::SelectQueryInfo const&, DB::SelectQueryOptions&, std::unordered_set, std::equal_to, std::allocator> const&, std::shared_ptr&) @ 0x000000001498e109 13. /build/src/Planner/Planner.cpp:1553: DB::Planner::buildPlanForQueryNode() @ 0x0000000014979dae 14. /build/src/Planner/Planner.cpp:1308: DB::Planner::buildQueryPlanIfNeeded() @ 0x000000001497685c 15. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:255: DB::InterpreterSelectQueryAnalyzer::getQueryPlan() @ 0x000000001497476d 16. /build/src/Interpreters/executeQuery.cpp:1405: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88806 17. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 18. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 19. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 20. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 21. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 22. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 23. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 24. ? @ 0x00007fbc6213eac3 25. ? @ 0x00007fbc621d0850 2025.07.28 11:50:31.661983 [ 5825 ] {f1b82854-cb99-4e77-9357-91a879cbaacb} executeQuery: Code: 439. DB::Exception: Cannot schedule a task: failed to start the thread (threads=0, jobs=0). (CANNOT_SCHEDULE_TASK) (version 25.3.6.10636.altinitytest (altinity build)) (from [::ffff:127.0.0.1]:51186) (comment: 02681_aggregation_by_partitions_bug.sql) (query 5, line 10) (in query: SELECT uniqExact(`__table1`.`a`) AS `countDistinct(a)` FROM `test_5evrphic`.`t` AS `__table1`), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000fccaeeb 4. /build/src/Common/ThreadPool.cpp:275: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000fccc813 5. /build/src/Common/ThreadPool.cpp:308: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fcc8286 6. /build/src/Common/ThreadPool.cpp:506: ThreadPoolImpl>::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000000fcc8c8d 7. /build/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) @ 0x00000000163f6c3a 8. /build/src/Processors/QueryPlan/ReadFromMergeTree.cpp:1810: 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) @ 0x0000000016e2b73d 9. /build/src/Processors/QueryPlan/ReadFromMergeTree.cpp:1516: DB::ReadFromMergeTree::selectRangesToRead(std::vector, std::allocator>>, bool) const @ 0x0000000016e2a679 10. /build/src/Processors/QueryPlan/ReadFromMergeTree.cpp:1511: DB::ReadFromMergeTree::selectRangesToRead(bool) const @ 0x0000000016e2a472 11. /build/src/Processors/QueryPlan/ReadFromMergeTree.cpp:1998: DB::ReadFromMergeTree::initializePipeline(DB::QueryPipelineBuilder&, DB::BuildQueryPipelineSettings const&) @ 0x0000000016e3248c 12. /build/src/Processors/QueryPlan/ISourceStep.cpp:20: DB::ISourceStep::updatePipeline(std::vector>, std::allocator>>>, DB::BuildQueryPipelineSettings const&) @ 0x0000000016dd18d0 13. /build/src/Processors/QueryPlan/QueryPlan.cpp:201: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x0000000016e0076f 14. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:275: DB::InterpreterSelectQueryAnalyzer::buildQueryPipeline() @ 0x0000000014974614 15. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:242: DB::InterpreterSelectQueryAnalyzer::execute() @ 0x000000001497439e 16. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88dc9 17. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 18. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 19. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 20. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 21. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 22. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 23. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 24. ? @ 0x00007fbc6213eac3 25. ? @ 0x00007fbc621d0850 2025.07.28 11:50:31.684623 [ 5825 ] {} 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. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000fccaeeb 4. /build/src/Common/ThreadPool.cpp:275: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000fccc813 5. /build/src/Common/ThreadPool.cpp:308: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fcc8286 6. /build/src/Common/ThreadPool.cpp:506: ThreadPoolImpl>::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000000fcc8c8d 7. /build/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) @ 0x00000000163f6c3a 8. /build/src/Processors/QueryPlan/ReadFromMergeTree.cpp:1810: 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) @ 0x0000000016e2b73d 9. /build/src/Processors/QueryPlan/ReadFromMergeTree.cpp:1516: DB::ReadFromMergeTree::selectRangesToRead(std::vector, std::allocator>>, bool) const @ 0x0000000016e2a679 10. /build/src/Processors/QueryPlan/ReadFromMergeTree.cpp:1511: DB::ReadFromMergeTree::selectRangesToRead(bool) const @ 0x0000000016e2a472 11. /build/src/Processors/QueryPlan/ReadFromMergeTree.cpp:1998: DB::ReadFromMergeTree::initializePipeline(DB::QueryPipelineBuilder&, DB::BuildQueryPipelineSettings const&) @ 0x0000000016e3248c 12. /build/src/Processors/QueryPlan/ISourceStep.cpp:20: DB::ISourceStep::updatePipeline(std::vector>, std::allocator>>>, DB::BuildQueryPipelineSettings const&) @ 0x0000000016dd18d0 13. /build/src/Processors/QueryPlan/QueryPlan.cpp:201: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x0000000016e0076f 14. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:275: DB::InterpreterSelectQueryAnalyzer::buildQueryPipeline() @ 0x0000000014974614 15. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:242: DB::InterpreterSelectQueryAnalyzer::execute() @ 0x000000001497439e 16. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88dc9 17. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 18. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 19. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 20. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 21. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 22. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 23. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 24. ? @ 0x00007fbc6213eac3 25. ? @ 0x00007fbc621d0850 2025.07.28 11:50:31.851494 [ 4587 ] {17510b75-b59a-4396-9684-ad5eb34bee18} executeQuery: Code: 439. DB::Exception: Received from 127.0.0.8:9000. DB::Exception: Cannot schedule a task: failed to start the thread (threads=0, jobs=0). Stack trace: 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000fccaeeb 4. /build/src/Common/ThreadPool.cpp:275: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000fccc813 5. /build/src/Common/ThreadPool.cpp:308: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fcc8286 6. /build/src/Common/ThreadPool.cpp:506: ThreadPoolImpl>::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000000fcc8c8d 7. /build/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) @ 0x00000000163f6c3a 8. /build/src/Processors/QueryPlan/ReadFromMergeTree.cpp:1810: 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) @ 0x0000000016e2b73d 9. /build/src/Processors/QueryPlan/ReadFromMergeTree.cpp:1516: DB::ReadFromMergeTree::selectRangesToRead(std::vector, std::allocator>>, bool) const @ 0x0000000016e2a679 10. /build/src/Processors/QueryPlan/ReadFromMergeTree.cpp:1511: DB::ReadFromMergeTree::selectRangesToRead(bool) const @ 0x0000000016e2a472 11. /build/src/Processors/QueryPlan/ReadFromMergeTree.cpp:1998: DB::ReadFromMergeTree::initializePipeline(DB::QueryPipelineBuilder&, DB::BuildQueryPipelineSettings const&) @ 0x0000000016e3248c 12. /build/src/Processors/QueryPlan/ISourceStep.cpp:20: DB::ISourceStep::updatePipeline(std::vector>, std::allocator>>>, DB::BuildQueryPipelineSettings const&) @ 0x0000000016dd18d0 13. /build/src/Processors/QueryPlan/QueryPlan.cpp:201: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x0000000016e0076f 14. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:275: DB::InterpreterSelectQueryAnalyzer::buildQueryPipeline() @ 0x0000000014974614 15. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:242: DB::InterpreterSelectQueryAnalyzer::execute() @ 0x000000001497439e 16. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88dc9 17. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 18. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 19. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 20. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 21. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 22. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 23. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 24. ? @ 0x00007fbc6213eac3 25. ? @ 0x00007fbc621d0850 : While executing Remote. (CANNOT_SCHEDULE_TASK) (version 25.3.6.10636.altinitytest (altinity build)) (from [::1]:60754) (comment: 02681_aggregation_by_partitions_bug.sql) (query 5, line 10) (in query: select count(distinct a) from t;), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:111: DB::readException(DB::ReadBuffer&, String const&, bool) @ 0x000000000fc6e157 3. /build/src/Client/Connection.cpp:1445: DB::Connection::receiveException() const @ 0x00000000167d4127 4. /build/src/Client/Connection.cpp:1274: DB::Connection::receivePacket() @ 0x00000000167db312 5. /build/src/Client/MultiplexedConnections.cpp:380: DB::MultiplexedConnections::receivePacketUnlocked(std::function) @ 0x00000000168163a9 6. /build/src/QueryPipeline/RemoteQueryExecutorReadContext.cpp:67: DB::RemoteQueryExecutorReadContext::Task::run(std::function, std::function) @ 0x0000000013bd23fe 7. /build/src/Common/AsyncTaskExecutor.cpp:89: DB::AsyncTaskExecutor::Routine::operator()(std::function) @ 0x0000000013bd1892 8. /build/src/Common/Fiber.h:76: boost::context::detail::fiber_record>::run(void*) @ 0x0000000013bd16fa 9. /build/contrib/boost/boost/context/fiber_fcontext.hpp:97: void boost::context::detail::fiber_entry>>(boost::context::detail::transfer_t) @ 0x0000000013bd1621 2025.07.28 11:50:31.951865 [ 4587 ] {} TCPHandler: Code: 439. DB::Exception: Received from 127.0.0.8:9000. DB::Exception: Cannot schedule a task: failed to start the thread (threads=0, jobs=0). Stack trace: 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000fccaeeb 4. /build/src/Common/ThreadPool.cpp:275: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000fccc813 5. /build/src/Common/ThreadPool.cpp:308: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fcc8286 6. /build/src/Common/ThreadPool.cpp:506: ThreadPoolImpl>::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000000fcc8c8d 7. /build/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) @ 0x00000000163f6c3a 8. /build/src/Processors/QueryPlan/ReadFromMergeTree.cpp:1810: 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) @ 0x0000000016e2b73d 9. /build/src/Processors/QueryPlan/ReadFromMergeTree.cpp:1516: DB::ReadFromMergeTree::selectRangesToRead(std::vector, std::allocator>>, bool) const @ 0x0000000016e2a679 10. /build/src/Processors/QueryPlan/ReadFromMergeTree.cpp:1511: DB::ReadFromMergeTree::selectRangesToRead(bool) const @ 0x0000000016e2a472 11. /build/src/Processors/QueryPlan/ReadFromMergeTree.cpp:1998: DB::ReadFromMergeTree::initializePipeline(DB::QueryPipelineBuilder&, DB::BuildQueryPipelineSettings const&) @ 0x0000000016e3248c 12. /build/src/Processors/QueryPlan/ISourceStep.cpp:20: DB::ISourceStep::updatePipeline(std::vector>, std::allocator>>>, DB::BuildQueryPipelineSettings const&) @ 0x0000000016dd18d0 13. /build/src/Processors/QueryPlan/QueryPlan.cpp:201: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x0000000016e0076f 14. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:275: DB::InterpreterSelectQueryAnalyzer::buildQueryPipeline() @ 0x0000000014974614 15. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:242: DB::InterpreterSelectQueryAnalyzer::execute() @ 0x000000001497439e 16. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88dc9 17. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 18. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 19. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 20. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 21. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 22. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 23. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 24. ? @ 0x00007fbc6213eac3 25. ? @ 0x00007fbc621d0850 : While executing Remote. (CANNOT_SCHEDULE_TASK), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:111: DB::readException(DB::ReadBuffer&, String const&, bool) @ 0x000000000fc6e157 3. /build/src/Client/Connection.cpp:1445: DB::Connection::receiveException() const @ 0x00000000167d4127 4. /build/src/Client/Connection.cpp:1274: DB::Connection::receivePacket() @ 0x00000000167db312 5. /build/src/Client/MultiplexedConnections.cpp:380: DB::MultiplexedConnections::receivePacketUnlocked(std::function) @ 0x00000000168163a9 6. /build/src/QueryPipeline/RemoteQueryExecutorReadContext.cpp:67: DB::RemoteQueryExecutorReadContext::Task::run(std::function, std::function) @ 0x0000000013bd23fe 7. /build/src/Common/AsyncTaskExecutor.cpp:89: DB::AsyncTaskExecutor::Routine::operator()(std::function) @ 0x0000000013bd1892 8. /build/src/Common/Fiber.h:76: boost::context::detail::fiber_record>::run(void*) @ 0x0000000013bd16fa 9. /build/contrib/boost/boost/context/fiber_fcontext.hpp:97: void boost::context::detail::fiber_entry>>(boost::context::detail::transfer_t) @ 0x0000000013bd1621 Job's origin stack trace: 0. /build/src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000000fc33b84 1. /build/src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000000fcc2ea7 2. /build/src/Common/ThreadPool.cpp:401: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fcc7f1c 3. /build/src/Common/ThreadPool.cpp:494: ThreadPoolImpl>::scheduleOrThrowOnError(std::function, Priority) @ 0x000000000fcc7a0e 4. /build/src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::spawnThreadsImpl() @ 0x00000000169b2c0c 5. /build/src/Processors/Executors/PipelineExecutor.cpp:394: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x00000000169b0ba7 6. /build/src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x00000000169b03f4 7. /build/src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:se190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169bfeab 8. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc3d92 9. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fcca080 10. ? @ 0x00007fbc6213eac3 11. ? @ 0x00007fbc621d0850 Job's origin stack trace: 0. /build/src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000000fc33b84 1. /build/src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000000fcc2ea7 2. /build/src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fcc535c 3. /build/src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000000fcc584d 4. /build/src/Common/ThreadPool.h:279: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x00000000169bf193 5. /build/src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x00000000169bf518 6. /build/src/Server/TCPHandler.cpp:1237: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x00000000168f1525 7. /build/src/Server/TCPHandler.cpp:678: DB::TCPHandler::runImpl() @ 0x00000000168e68e5 8. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 9. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 10. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 11. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 12. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 13. ? @ 0x00007fbc6213eac3 14. ? @ 0x00007fbc621d0850 2025.07.28 11:50:31.970974 [ 4454 ] {dabfc71e-9166-4a4e-ab38-ede47252ec31} executeQuery: Code: 210. DB::NetException: Connection reset by peer, while writing to socket ([::ffff:127.0.0.3]:9000 -> [::ffff:127.0.0.1]:59208). (NETWORK_ERROR) (version 25.3.6.10636.altinitytest (altinity build)) (from [::ffff:127.0.0.1]:59208) (comment: 02681_aggregation_by_partitions_bug.sql) (query 5, line 10) (in query: SELECT uniqExact(`__table1`.`a`) AS `countDistinct(a)` FROM `test_5evrphic`.`t` AS `__table1`), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::NetException::NetException(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&) @ 0x000000000fd50fb5 3. /build/src/IO/WriteBufferFromPocoSocket.cpp:160: DB::WriteBufferFromPocoSocket::nextImpl() @ 0x000000000fd523f1 4. /build/src/IO/WriteBuffer.h:53: DB::WriteBuffer::next() @ 0x000000000a0755be 5. /build/src/Server/TCPHandler.cpp:2570: DB::TCPHandler::runImpl() @ 0x00000000168e6991 6. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 7. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 8. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 9. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 10. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 11. ? @ 0x00007fbc6213eac3 12. ? @ 0x00007fbc621d0850 2025.07.28 11:50:31.972511 [ 3287 ] {9fbb38a0-947e-4a30-a53d-4d7c61356c7c} executeQuery: Code: 210. DB::NetException: Connection reset by peer, while writing to socket ([::ffff:127.0.0.4]:9000 -> [::ffff:127.0.0.1]:56426). (NETWORK_ERROR) (version 25.3.6.10636.altinitytest (altinity build)) (from [::ffff:127.0.0.1]:56426) (comment: 02681_aggregation_by_partitions_bug.sql) (query 5, line 10) (in query: SELECT uniqExact(`__table1`.`a`) AS `countDistinct(a)` FROM `test_5evrphic`.`t` AS `__table1`), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::NetException::NetException(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&) @ 0x000000000fd50fb5 3. /build/src/IO/WriteBufferFromPocoSocket.cpp:160: DB::WriteBufferFromPocoSocket::nextImpl() @ 0x000000000fd523f1 4. /build/src/IO/WriteBuffer.h:53: DB::WriteBuffer::next() @ 0x000000000a0755be 5. /build/src/Server/TCPHandler.cpp:2570: DB::TCPHandler::runImpl() @ 0x00000000168e6991 6. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 7. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 8. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 9. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 10. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 11. ? @ 0x00007fbc6213eac3 12. ? @ 0x00007fbc621d0850 2025.07.28 11:50:31.978034 [ 3287 ] {} TCPHandler: Code: 210. DB::NetException: Connection reset by peer, while writing to socket ([::ffff:127.0.0.4]:9000 -> [::ffff:127.0.0.1]:56426). (NETWORK_ERROR), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::NetException::NetException(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&) @ 0x000000000fd50fb5 3. /build/src/IO/WriteBufferFromPocoSocket.cpp:160: DB::WriteBufferFromPocoSocket::nextImpl() @ 0x000000000fd523f1 4. /build/src/IO/WriteBuffer.h:53: DB::WriteBuffer::next() @ 0x000000000a0755be 5. /build/src/Server/TCPHandler.cpp:2570: DB::TCPHandler::runImpl() @ 0x00000000168e6991 6. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 7. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 8. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 9. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 10. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 11. ? @ 0x00007fbc6213eac3 12. ? @ 0x00007fbc621d0850 2025.07.28 11:50:31.983982 [ 4454 ] {} TCPHandler: Code: 210. DB::NetException: Connection reset by peer, while writing to socket ([::ffff:127.0.0.3]:9000 -> [::ffff:127.0.0.1]:59208). (NETWORK_ERROR), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::NetException::NetException(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&) @ 0x000000000fd50fb5 3. /build/src/IO/WriteBufferFromPocoSocket.cpp:160: DB::WriteBufferFromPocoSocket::nextImpl() @ 0x000000000fd523f1 4. /build/src/IO/WriteBuffer.h:53: DB::WriteBuffer::next() @ 0x000000000a0755be 5. /build/src/Server/TCPHandler.cpp:2570: DB::TCPHandler::runImpl() @ 0x00000000168e6991 6. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 7. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 8. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 9. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 10. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 11. ? @ 0x00007fbc6213eac3 12. ? @ 0x00007fbc621d0850 2025.07.28 11:50:32.188822 [ 4900 ] {fc27735d-e765-434f-85cd-0d768f2fd03d} executeQuery: Code: 219. DB::Exception: New table appeared in database being dropped or detached. Try again. (DATABASE_NOT_EMPTY) (version 25.3.6.10636.altinitytest (altinity build)) (from [::1]:51220) (comment: 02681_aggregation_by_partitions_bug.sql) (in query: DROP DATABASE IF EXISTS test_5evrphic SYNC ), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000000a074fcb 4. /build/src/Interpreters/DatabaseCatalog.cpp:608: DB::DatabaseCatalog::detachDatabase(std::shared_ptr, String const&, bool, bool) @ 0x00000000144f41b9 5. /build/src/Interpreters/InterpreterDropQuery.cpp:482: DB::InterpreterDropQuery::executeToDatabaseImpl(DB::ASTDropQuery const&, std::shared_ptr&, std::vector, DB::UUIDTag>, std::allocator, DB::UUIDTag>>>&) @ 0x00000000149179be 6. /build/src/Interpreters/InterpreterDropQuery.cpp:363: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x0000000014913988 7. /build/src/Interpreters/InterpreterDropQuery.cpp:99: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000014913142 8. /build/src/Interpreters/InterpreterDropQuery.cpp:72: DB::InterpreterDropQuery::execute() @ 0x0000000014912b65 9. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88dc9 10. /build/src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x0000000014c8ca7b 11. /build/src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000001686da12 12. /build/src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x0000000016870807 13. /build/src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x0000000016907e99 14. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 15. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 16. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 17. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 18. ? @ 0x00007fbc6213eac3 19. ? @ 0x00007fbc621d0850 2025.07.28 11:50:32.289617 [ 4900 ] {fc27735d-e765-434f-85cd-0d768f2fd03d} 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. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000000a074fcb 4. /build/src/Interpreters/DatabaseCatalog.cpp:608: DB::DatabaseCatalog::detachDatabase(std::shared_ptr, String const&, bool, bool) @ 0x00000000144f41b9 5. /build/src/Interpreters/InterpreterDropQuery.cpp:482: DB::InterpreterDropQuery::executeToDatabaseImpl(DB::ASTDropQuery const&, std::shared_ptr&, std::vector, DB::UUIDTag>, std::allocator, DB::UUIDTag>>>&) @ 0x00000000149179be 6. /build/src/Interpreters/InterpreterDropQuery.cpp:363: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x0000000014913988 7. /build/src/Interpreters/InterpreterDropQuery.cpp:99: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000014913142 8. /build/src/Interpreters/InterpreterDropQuery.cpp:72: DB::InterpreterDropQuery::execute() @ 0x0000000014912b65 9. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88dc9 10. /build/src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x0000000014c8ca7b 11. /build/src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000001686da12 12. /build/src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x0000000016870807 13. /build/src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x0000000016907e99 14. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 15. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 16. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 17. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 18. ? @ 0x00007fbc6213eac3 19. ? @ 0x00007fbc621d0850 (version 25.3.6.10636.altinitytest (altinity build)) 2025.07.28 11:50:32.424663 [ 5980 ] {ef173360-8277-4577-b1fa-de79a2985c3f} executeQuery: Code: 47. DB::Exception: Unknown expression or function identifier `x` in scope x = 1. (UNKNOWN_IDENTIFIER) (version 25.3.6.10636.altinitytest (altinity build)) (from [::1]:52688) (comment: 03040_alias_column_join.sql) (query 4, line 12) (in query: SELECT val FROM 03040_test t GROUP BY val;), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.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&&) @ 0x000000001404b3b9 4. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3771: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000001401b849 5. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3980: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000014018e31 6. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:2925: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000001402fcbd 7. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3838: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000014019a9e 8. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:209: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000001401270e 9. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000014011fce 10. /build/src/Planner/Utils.cpp:458: DB::buildFilterInfo(std::shared_ptr, std::shared_ptr const&, std::shared_ptr&, std::unordered_set, std::equal_to, std::allocator>) @ 0x0000000013fe8bcf 11. /build/src/Planner/PlannerJoinTree.cpp:535: DB::(anonymous namespace)::buildQueryPlanForTableExpression(std::shared_ptr, std::shared_ptr const&, DB::SelectQueryInfo const&, DB::SelectQueryOptions const&, std::shared_ptr&, bool, bool) @ 0x00000000149956d3 12. /build/src/Planner/PlannerJoinTree.cpp:2252: DB::buildJoinTreeQueryPlan(std::shared_ptr const&, DB::SelectQueryInfo const&, DB::SelectQueryOptions&, std::unordered_set, std::equal_to, std::allocator> const&, std::shared_ptr&) @ 0x000000001498e109 13. /build/src/Planner/Planner.cpp:1553: DB::Planner::buildPlanForQueryNode() @ 0x0000000014979dae 14. /build/src/Planner/Planner.cpp:1308: DB::Planner::buildQueryPlanIfNeeded() @ 0x000000001497685c 15. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:255: DB::InterpreterSelectQueryAnalyzer::getQueryPlan() @ 0x000000001497476d 16. /build/src/Interpreters/executeQuery.cpp:1405: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88806 17. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 18. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 19. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 20. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 21. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 22. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 23. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 24. ? @ 0x00007fbc6213eac3 25. ? @ 0x00007fbc621d0850 2025.07.28 11:50:32.461371 [ 5980 ] {} TCPHandler: Code: 47. DB::Exception: Unknown expression or function identifier `x` in scope x = 1. (UNKNOWN_IDENTIFIER), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.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&&) @ 0x000000001404b3b9 4. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3771: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000001401b849 5. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3980: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000014018e31 6. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:2925: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000001402fcbd 7. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3838: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000014019a9e 8. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:209: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000001401270e 9. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000014011fce 10. /build/src/Planner/Utils.cpp:458: DB::buildFilterInfo(std::shared_ptr, std::shared_ptr const&, std::shared_ptr&, std::unordered_set, std::equal_to, std::allocator>) @ 0x0000000013fe8bcf 11. /build/src/Planner/PlannerJoinTree.cpp:535: DB::(anonymous namespace)::buildQueryPlanForTableExpression(std::shared_ptr, std::shared_ptr const&, DB::SelectQueryInfo const&, DB::SelectQueryOptions const&, std::shared_ptr&, bool, bool) @ 0x00000000149956d3 12. /build/src/Planner/PlannerJoinTree.cpp:2252: DB::buildJoinTreeQueryPlan(std::shared_ptr const&, DB::SelectQueryInfo const&, DB::SelectQueryOptions&, std::unordered_set, std::equal_to, std::allocator> const&, std::shared_ptr&) @ 0x000000001498e109 13. /build/src/Planner/Planner.cpp:1553: DB::Planner::buildPlanForQueryNode() @ 0x0000000014979dae 14. /build/src/Planner/Planner.cpp:1308: DB::Planner::buildQueryPlanIfNeeded() @ 0x000000001497685c 15. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:255: DB::InterpreterSelectQueryAnalyzer::getQueryPlan() @ 0x000000001497476d 16. /build/src/Interpreters/executeQuery.cpp:1405: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88806 17. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 18. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 19. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 20. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 21. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 22. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 23. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 24. ? @ 0x00007fbc6213eac3 25. ? @ 0x00007fbc621d0850 2025.07.28 11:50:32.476578 [ 5146 ] {edf1165f-2a95-4140-b5b4-b8792af4b115} executeQuery: Code: 219. DB::Exception: New table appeared in database being dropped or detached. Try again. (DATABASE_NOT_EMPTY) (version 25.3.6.10636.altinitytest (altinity build)) (from [::1]:51236) (comment: 02681_aggregation_by_partitions_bug.sql) (in query: DROP DATABASE IF EXISTS test_5evrphic SYNC ), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000000a074fcb 4. /build/src/Interpreters/DatabaseCatalog.cpp:608: DB::DatabaseCatalog::detachDatabase(std::shared_ptr, String const&, bool, bool) @ 0x00000000144f41b9 5. /build/src/Interpreters/InterpreterDropQuery.cpp:482: DB::InterpreterDropQuery::executeToDatabaseImpl(DB::ASTDropQuery const&, std::shared_ptr&, std::vector, DB::UUIDTag>, std::allocator, DB::UUIDTag>>>&) @ 0x00000000149179be 6. /build/src/Interpreters/InterpreterDropQuery.cpp:363: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x0000000014913988 7. /build/src/Interpreters/InterpreterDropQuery.cpp:99: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000014913142 8. /build/src/Interpreters/InterpreterDropQuery.cpp:72: DB::InterpreterDropQuery::execute() @ 0x0000000014912b65 9. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88dc9 10. /build/src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x0000000014c8ca7b 11. /build/src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000001686da12 12. /build/src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x0000000016870807 13. /build/src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x0000000016907e99 14. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 15. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 16. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 17. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 18. ? @ 0x00007fbc6213eac3 19. ? @ 0x00007fbc621d0850 2025.07.28 11:50:32.481459 [ 5146 ] {edf1165f-2a95-4140-b5b4-b8792af4b115} 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. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000000a074fcb 4. /build/src/Interpreters/DatabaseCatalog.cpp:608: DB::DatabaseCatalog::detachDatabase(std::shared_ptr, String const&, bool, bool) @ 0x00000000144f41b9 5. /build/src/Interpreters/InterpreterDropQuery.cpp:482: DB::InterpreterDropQuery::executeToDatabaseImpl(DB::ASTDropQuery const&, std::shared_ptr&, std::vector, DB::UUIDTag>, std::allocator, DB::UUIDTag>>>&) @ 0x00000000149179be 6. /build/src/Interpreters/InterpreterDropQuery.cpp:363: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x0000000014913988 7. /build/src/Interpreters/InterpreterDropQuery.cpp:99: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000014913142 8. /build/src/Interpreters/InterpreterDropQuery.cpp:72: DB::InterpreterDropQuery::execute() @ 0x0000000014912b65 9. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88dc9 10. /build/src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x0000000014c8ca7b 11. /build/src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000001686da12 12. /build/src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x0000000016870807 13. /build/src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x0000000016907e99 14. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 15. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 16. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 17. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 18. ? @ 0x00007fbc6213eac3 19. ? @ 0x00007fbc621d0850 (version 25.3.6.10636.altinitytest (altinity build)) 2025.07.28 11:50:32.615104 [ 4900 ] {f8dca1fe-ae7e-4ec5-9e4f-df63a635cf07} executeQuery: Code: 60. DB::Exception: Table test_s4mjq9ya.ddl_test_for_opentelemetry_non_exist does not exist. (UNKNOWN_TABLE) (version 25.3.6.10636.altinitytest (altinity build)) (from [::1]:52776) (comment: 02423_ddl_for_opentelemetry.sh) (query 1, line 1) (in query: DROP TABLE test_s4mjq9ya.ddl_test_for_opentelemetry_non_exist ON CLUSTER test_s4mjq9ya), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000a06a8eb 4. /build/src/Databases/IDatabase.cpp:41: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x0000000013dd565f 5. /build/src/Interpreters/DatabaseCatalog.cpp:442: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x00000000144f0869 6. /build/src/Interpreters/DatabaseCatalog.cpp:990: DB::DatabaseCatalog::getDatabaseAndTable(DB::StorageID const&, std::shared_ptr) const @ 0x00000000144f6e1d 7. /build/src/Interpreters/InterpreterDropQuery.cpp:146: DB::InterpreterDropQuery::executeToTableImpl(std::shared_ptr const&, DB::ASTDropQuery&, std::shared_ptr&, StrongTypedef, DB::UUIDTag>&) @ 0x00000000149140bf 8. /build/src/Interpreters/InterpreterDropQuery.cpp:118: DB::InterpreterDropQuery::executeToTable(DB::ASTDropQuery&) @ 0x00000000149137b4 9. /build/src/Interpreters/InterpreterDropQuery.cpp:91: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000014912f07 10. /build/src/Interpreters/InterpreterDropQuery.cpp:72: DB::InterpreterDropQuery::execute() @ 0x0000000014912b65 11. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88dc9 12. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 13. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 14. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 15. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 16. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 17. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 18. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 19. ? @ 0x00007fbc6213eac3 20. ? @ 0x00007fbc621d0850 2025.07.28 11:50:32.628970 [ 4900 ] {} TCPHandler: Code: 60. DB::Exception: Table test_s4mjq9ya.ddl_test_for_opentelemetry_non_exist does not exist. (UNKNOWN_TABLE), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000a06a8eb 4. /build/src/Databases/IDatabase.cpp:41: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x0000000013dd565f 5. /build/src/Interpreters/DatabaseCatalog.cpp:442: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x00000000144f0869 6. /build/src/Interpreters/DatabaseCatalog.cpp:990: DB::DatabaseCatalog::getDatabaseAndTable(DB::StorageID const&, std::shared_ptr) const @ 0x00000000144f6e1d 7. /build/src/Interpreters/InterpreterDropQuery.cpp:146: DB::InterpreterDropQuery::executeToTableImpl(std::shared_ptr const&, DB::ASTDropQuery&, std::shared_ptr&, StrongTypedef, DB::UUIDTag>&) @ 0x00000000149140bf 8. /build/src/Interpreters/InterpreterDropQuery.cpp:118: DB::InterpreterDropQuery::executeToTable(DB::ASTDropQuery&) @ 0x00000000149137b4 9. /build/src/Interpreters/InterpreterDropQuery.cpp:91: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000014912f07 10. /build/src/Interpreters/InterpreterDropQuery.cpp:72: DB::InterpreterDropQuery::execute() @ 0x0000000014912b65 11. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88dc9 12. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 13. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 14. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 15. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 16. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 17. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 18. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 19. ? @ 0x00007fbc6213eac3 20. ? @ 0x00007fbc621d0850 2025.07.28 11:50:32.820495 [ 4454 ] {d93a2760-e2b7-405e-aaa8-64257cb93225} executeQuery: Code: 452. DB::Exception: Setting allow_experimental_object_type should not be changed. (SETTING_CONSTRAINT_VIOLATION) (version 25.3.6.10636.altinitytest (altinity build)) (from [::1]:52778) (comment: 01825_type_json_insert_select.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. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x000000000c25bc4b 4. /build/src/Access/SettingsConstraints.cpp:343: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000138596e3 5. /build/src/Access/SettingsConstraints.cpp:300: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000013858faf 6. /build/src/Access/SettingsConstraints.cpp:194: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges const&, DB::SettingSource) const @ 0x00000000138591b3 7. /build/src/Interpreters/Context.cpp:2722: DB::Context::checkSettingsConstraints(DB::SettingsChanges const&, DB::SettingSource) @ 0x0000000014436509 8. /build/src/Interpreters/InterpreterSetQuery.cpp:28: DB::InterpreterSetQuery::execute() @ 0x00000000149e240a 9. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88dc9 10. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 11. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 12. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 13. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 14. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 16. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 17. ? @ 0x00007fbc6213eac3 18. ? @ 0x00007fbc621d0850 2025.07.28 11:50:32.835264 [ 4454 ] {} 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. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x000000000c25bc4b 4. /build/src/Access/SettingsConstraints.cpp:343: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000138596e3 5. /build/src/Access/SettingsConstraints.cpp:300: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000013858faf 6. /build/src/Access/SettingsConstraints.cpp:194: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges const&, DB::SettingSource) const @ 0x00000000138591b3 7. /build/src/Interpreters/Context.cpp:2722: DB::Context::checkSettingsConstraints(DB::SettingsChanges const&, DB::SettingSource) @ 0x0000000014436509 8. /build/src/Interpreters/InterpreterSetQuery.cpp:28: DB::InterpreterSetQuery::execute() @ 0x00000000149e240a 9. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88dc9 10. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 11. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 12. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 13. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 14. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 16. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 17. ? @ 0x00007fbc6213eac3 18. ? @ 0x00007fbc621d0850 2025.07.28 11:50:33.959744 [ 5825 ] {06c7b15e-fc83-417c-9a66-208cb775af15} executeQuery: Code: 47. DB::Exception: Unknown expression or function identifier `x` in scope x = 1. (UNKNOWN_IDENTIFIER) (version 25.3.6.10636.altinitytest (altinity build)) (from [::1]:52838) (comment: 01349_mutation_datetime_key.sql) (query 4, line 16) (in query: SELECT * FROM cdp_orders;), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.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&&) @ 0x000000001404b3b9 4. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3771: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000001401b849 5. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3980: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000014018e31 6. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:2925: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000001402fcbd 7. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3838: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000014019a9e 8. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:209: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000001401270e 9. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000014011fce 10. /build/src/Planner/Utils.cpp:458: DB::buildFilterInfo(std::shared_ptr, std::shared_ptr const&, std::shared_ptr&, std::unordered_set, std::equal_to, std::allocator>) @ 0x0000000013fe8bcf 11. /build/src/Planner/PlannerJoinTree.cpp:535: DB::(anonymous namespace)::buildQueryPlanForTableExpression(std::shared_ptr, std::shared_ptr const&, DB::SelectQueryInfo const&, DB::SelectQueryOptions const&, std::shared_ptr&, bool, bool) @ 0x00000000149956d3 12. /build/src/Planner/PlannerJoinTree.cpp:2252: DB::buildJoinTreeQueryPlan(std::shared_ptr const&, DB::SelectQueryInfo const&, DB::SelectQueryOptions&, std::unordered_set, std::equal_to, std::allocator> const&, std::shared_ptr&) @ 0x000000001498e109 13. /build/src/Planner/Planner.cpp:1553: DB::Planner::buildPlanForQueryNode() @ 0x0000000014979dae 14. /build/src/Planner/Planner.cpp:1308: DB::Planner::buildQueryPlanIfNeeded() @ 0x000000001497685c 15. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:255: DB::InterpreterSelectQueryAnalyzer::getQueryPlan() @ 0x000000001497476d 16. /build/src/Interpreters/executeQuery.cpp:1405: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88806 17. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 18. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 19. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 20. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 21. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 22. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 23. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 24. ? @ 0x00007fbc6213eac3 25. ? @ 0x00007fbc621d0850 2025.07.28 11:50:33.974747 [ 5825 ] {} TCPHandler: Code: 47. DB::Exception: Unknown expression or function identifier `x` in scope x = 1. (UNKNOWN_IDENTIFIER), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.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&&) @ 0x000000001404b3b9 4. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3771: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000001401b849 5. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3980: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000014018e31 6. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:2925: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000001402fcbd 7. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3838: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000014019a9e 8. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:209: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000001401270e 9. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000014011fce 10. /build/src/Planner/Utils.cpp:458: DB::buildFilterInfo(std::shared_ptr, std::shared_ptr const&, std::shared_ptr&, std::unordered_set, std::equal_to, std::allocator>) @ 0x0000000013fe8bcf 11. /build/src/Planner/PlannerJoinTree.cpp:535: DB::(anonymous namespace)::buildQueryPlanForTableExpression(std::shared_ptr, std::shared_ptr const&, DB::SelectQueryInfo const&, DB::SelectQueryOptions const&, std::shared_ptr&, bool, bool) @ 0x00000000149956d3 12. /build/src/Planner/PlannerJoinTree.cpp:2252: DB::buildJoinTreeQueryPlan(std::shared_ptr const&, DB::SelectQueryInfo const&, DB::SelectQueryOptions&, std::unordered_set, std::equal_to, std::allocator> const&, std::shared_ptr&) @ 0x000000001498e109 13. /build/src/Planner/Planner.cpp:1553: DB::Planner::buildPlanForQueryNode() @ 0x0000000014979dae 14. /build/src/Planner/Planner.cpp:1308: DB::Planner::buildQueryPlanIfNeeded() @ 0x000000001497685c 15. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:255: DB::InterpreterSelectQueryAnalyzer::getQueryPlan() @ 0x000000001497476d 16. /build/src/Interpreters/executeQuery.cpp:1405: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88806 17. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 18. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 19. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 20. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 21. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 22. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 23. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 24. ? @ 0x00007fbc6213eac3 25. ? @ 0x00007fbc621d0850 2025.07.28 11:50:34.911483 [ 6138 ] {023bc14a-f965-4c33-8ab1-0f2b0bbb0c5a} executeQuery: Code: 47. DB::Exception: Unknown expression or function identifier `x` in scope x = 1. (UNKNOWN_IDENTIFIER) (version 25.3.6.10636.altinitytest (altinity build)) (from [::1]:52972) (comment: 01073_crlf_end_of_line.sql) (query 4, line 4) (in query: SELECT * FROM test_01073_crlf_end_of_line FORMAT CSV SETTINGS output_format_csv_crlf_end_of_line = 1;), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.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&&) @ 0x000000001404b3b9 4. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3771: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000001401b849 5. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3980: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000014018e31 6. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:2925: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000001402fcbd 7. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3838: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000014019a9e 8. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:209: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000001401270e 9. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000014011fce 10. /build/src/Planner/Utils.cpp:458: DB::buildFilterInfo(std::shared_ptr, std::shared_ptr const&, std::shared_ptr&, std::unordered_set, std::equal_to, std::allocator>) @ 0x0000000013fe8bcf 11. /build/src/Planner/PlannerJoinTree.cpp:535: DB::(anonymous namespace)::buildQueryPlanForTableExpression(std::shared_ptr, std::shared_ptr const&, DB::SelectQueryInfo const&, DB::SelectQueryOptions const&, std::shared_ptr&, bool, bool) @ 0x00000000149956d3 12. /build/src/Planner/PlannerJoinTree.cpp:2252: DB::buildJoinTreeQueryPlan(std::shared_ptr const&, DB::SelectQueryInfo const&, DB::SelectQueryOptions&, std::unordered_set, std::equal_to, std::allocator> const&, std::shared_ptr&) @ 0x000000001498e109 13. /build/src/Planner/Planner.cpp:1553: DB::Planner::buildPlanForQueryNode() @ 0x0000000014979dae 14. /build/src/Planner/Planner.cpp:1308: DB::Planner::buildQueryPlanIfNeeded() @ 0x000000001497685c 15. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:255: DB::InterpreterSelectQueryAnalyzer::getQueryPlan() @ 0x000000001497476d 16. /build/src/Interpreters/executeQuery.cpp:1405: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88806 17. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 18. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 19. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 20. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 21. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 22. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 23. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 24. ? @ 0x00007fbc6213eac3 25. ? @ 0x00007fbc621d0850 2025.07.28 11:50:34.931320 [ 6138 ] {} TCPHandler: Code: 47. DB::Exception: Unknown expression or function identifier `x` in scope x = 1. (UNKNOWN_IDENTIFIER), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.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&&) @ 0x000000001404b3b9 4. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3771: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000001401b849 5. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3980: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000014018e31 6. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:2925: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000001402fcbd 7. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3838: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000014019a9e 8. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:209: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000001401270e 9. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000014011fce 10. /build/src/Planner/Utils.cpp:458: DB::buildFilterInfo(std::shared_ptr, std::shared_ptr const&, std::shared_ptr&, std::unordered_set, std::equal_to, std::allocator>) @ 0x0000000013fe8bcf 11. /build/src/Planner/PlannerJoinTree.cpp:535: DB::(anonymous namespace)::buildQueryPlanForTableExpression(std::shared_ptr, std::shared_ptr const&, DB::SelectQueryInfo const&, DB::SelectQueryOptions const&, std::shared_ptr&, bool, bool) @ 0x00000000149956d3 12. /build/src/Planner/PlannerJoinTree.cpp:2252: DB::buildJoinTreeQueryPlan(std::shared_ptr const&, DB::SelectQueryInfo const&, DB::SelectQueryOptions&, std::unordered_set, std::equal_to, std::allocator> const&, std::shared_ptr&) @ 0x000000001498e109 13. /build/src/Planner/Planner.cpp:1553: DB::Planner::buildPlanForQueryNode() @ 0x0000000014979dae 14. /build/src/Planner/Planner.cpp:1308: DB::Planner::buildQueryPlanIfNeeded() @ 0x000000001497685c 15. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:255: DB::InterpreterSelectQueryAnalyzer::getQueryPlan() @ 0x000000001497476d 16. /build/src/Interpreters/executeQuery.cpp:1405: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88806 17. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 18. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 19. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 20. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 21. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 22. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 23. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 24. ? @ 0x00007fbc6213eac3 25. ? @ 0x00007fbc621d0850 2025.07.28 11:50:35.663732 [ 4446 ] {ed9e55de-3356-4d2f-9854-5a3861cedf29} executeQuery: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=4, jobs=0): While reading or decompressing /var/lib/clickhouse/store/057/057d9f5f-935e-4fb0-aa4d-d5515c7b79d1/202507_14_14_0/data.bin (position: 647, typename: DB::AsynchronousReadBufferFromFileWithDescriptorsCache, compressed data header: 234d7d7f5d4f230548121ed8d76add2b82ca130000d02c0000): (while reading column kind): (while reading from part /var/lib/clickhouse/store/057/057d9f5f-935e-4fb0-aa4d-d5515c7b79d1/202507_14_14_0/ in table system.opentelemetry_span_log (057d9f5f-935e-4fb0-aa4d-d5515c7b79d1) located on disk default of type local, from mark 0 with max_rows_to_read = 16): While executing MergeTreeSelect(pool: ReadPool, algorithm: Thread). (CANNOT_SCHEDULE_TASK) (version 25.3.6.10636.altinitytest (altinity build)) (from [::1]:52986) (comment: 02423_ddl_for_opentelemetry.sh) (query 2, line 4) (in query: SELECT count() FROM system.opentelemetry_span_log WHERE finish_date >= yesterday() AND lower(hex(trace_id)) = '72f37d7538834670a734a6b77122b1ef' AND operation_name like '%executeDDLQueryOnCluster%' AND attribute['clickhouse.cluster']='test_s4mjq9ya' AND kind = 'PRODUCER';), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000fccaeeb 4. /build/src/Common/ThreadPool.cpp:275: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000fccc813 5. /build/src/Common/ThreadPool.cpp:323: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fcc7bbc 6. /build/src/Common/ThreadPool.cpp:494: ThreadPoolImpl>::scheduleOrThrowOnError(std::function, Priority) @ 0x000000000fcc7a0e 7. /build/src/Common/threadPoolCallbackRunner.h:52: std::function (std::function&&, Priority)> DB::threadPoolCallbackRunnerUnsafe>(ThreadPoolImpl>&, String const&)::'lambda'(std::function&&, Priority)::operator()(std::function&&, Priority) @ 0x000000001320131a 8. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: std::future std::__function::__policy_invoker (std::function&&, Priority)>::__call_impl[abi:se190107] (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&&) @ 0x000000001320110f 9. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000132002ce 10. /build/src/IO/AsynchronousReadBufferFromFileDescriptor.cpp:62: DB::AsynchronousReadBufferFromFileDescriptor::asyncReadInto(char*, unsigned long, Priority) @ 0x00000000131f77d0 11. /build/src/IO/AsynchronousReadBufferFromFileDescriptor.cpp:100: DB::AsynchronousReadBufferFromFileDescriptor::nextImpl() @ 0x00000000131f7acb 12. /build/src/IO/ReadBuffer.h:60: DB::ReadBuffer::next() @ 0x000000000a148c7b 13. /build/src/IO/ReadBuffer.h:96: DB::CompressedReadBufferBase::readCompressedData(unsigned long&, unsigned long&, bool) @ 0x0000000017935e2b 14. /build/src/Compression/CompressedReadBufferFromFile.cpp:126: DB::CompressedReadBufferFromFile::readBig(char*, unsigned long) @ 0x0000000017938e9c 15. /build/src/DataTypes/Serializations/SerializationNumber.cpp:221: DB::SerializationNumber<_BitInt(8)>::deserializeBinaryBulk(DB::IColumn&, DB::ReadBuffer&, unsigned long, double) const @ 0x0000000013cdae58 16. /build/src/DataTypes/Serializations/ISerialization.cpp:147: DB::ISerialization::deserializeBinaryBulkWithMultipleStreams(COW::immutable_ptr&, unsigned long, DB::ISerialization::DeserializeBinaryBulkSettings&, std::shared_ptr&, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>*) const @ 0x0000000013c7b663 17. /build/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>>>*) @ 0x000000001648f4f9 18. /build/src/Storages/MergeTree/MergeTreeReaderCompactSingleBuffer.cpp:53: DB::MergeTreeReaderCompactSingleBuffer::readRows(unsigned long, unsigned long, bool, unsigned long, std::vector::immutable_ptr, std::allocator::immutable_ptr>>&) @ 0x00000000164a3ba0 19. /build/src/Storages/MergeTree/MergeTreeRangeReader.cpp:116: DB::MergeTreeRangeReader::DelayedStream::finalize(std::vector::immutable_ptr, std::allocator::immutable_ptr>>&) @ 0x0000000016497db1 20. /build/src/Storages/MergeTree/MergeTreeRangeReader.cpp:298: DB::MergeTreeRangeReader::startReadingChain(unsigned long, DB::MarkRanges&) @ 0x000000001649f129 21. /build/src/Storages/MergeTree/MergeTreeReadersChain.cpp:67: DB::MergeTreeReadersChain::read(unsigned long, DB::MarkRanges&) @ 0x00000000164b9dda 22. /build/src/Storages/MergeTree/MergeTreeReadTask.cpp:172: DB::MergeTreeReadTask::read() @ 0x00000000164b6300 23. /build/src/Storages/MergeTree/MergeTreeSelectAlgorithms.h:38: DB::MergeTreeThreadSelectAlgorithm::readFromTask(DB::MergeTreeReadTask&) @ 0x0000000016e3caac 24. /build/src/Storages/MergeTree/MergeTreeSelectProcessor.cpp:207: DB::MergeTreeSelectProcessor::read() @ 0x00000000164c0ba4 25. /build/src/Storages/MergeTree/MergeTreeSource.cpp:229: DB::MergeTreeSource::tryGenerate() @ 0x0000000016e43d69 26. /build/src/Processors/ISource.cpp:108: DB::ISource::work() @ 0x00000000169a21e7 27. /build/src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x00000000169bd00f 28. /build/src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x00000000169b2105 29. /build/src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeSingleThread(unsigned long) @ 0x00000000169b23be 30. /build/src/Processors/Executors/PipelineExecutor.cpp:416: void std::__function::__policy_invoker::__call_impl[abi:se190107]>(std::__function::__policy_storage const*) @ 0x00000000169b2e3f 31. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc6653 2025.07.28 11:50:35.777345 [ 4446 ] {} TCPHandler: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=4, jobs=0): While reading or decompressing /var/lib/clickhouse/store/057/057d9f5f-935e-4fb0-aa4d-d5515c7b79d1/202507_14_14_0/data.bin (position: 647, typename: DB::AsynchronousReadBufferFromFileWithDescriptorsCache, compressed data header: 234d7d7f5d4f230548121ed8d76add2b82ca130000d02c0000): (while reading column kind): (while reading from part /var/lib/clickhouse/store/057/057d9f5f-935e-4fb0-aa4d-d5515c7b79d1/202507_14_14_0/ in table system.opentelemetry_span_log (057d9f5f-935e-4fb0-aa4d-d5515c7b79d1) located on disk default of type local, from mark 0 with max_rows_to_read = 16): While executing MergeTreeSelect(pool: ReadPool, algorithm: Thread). (CANNOT_SCHEDULE_TASK), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000fccaeeb 4. /build/src/Common/ThreadPool.cpp:275: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000fccc813 5. /build/src/Common/ThreadPool.cpp:323: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fcc7bbc 6. /build/src/Common/ThreadPool.cpp:494: ThreadPoolImpl>::scheduleOrThrowOnError(std::function, Priority) @ 0x000000000fcc7a0e 7. /build/src/Common/threadPoolCallbackRunner.h:52: std::function (std::function&&, Priority)> DB::threadPoolCallbackRunnerUnsafe>(ThreadPoolImpl>&, String const&)::'lambda'(std::function&&, Priority)::operator()(std::function&&, Priority) @ 0x000000001320131a 8. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: std::future std::__function::__policy_invoker (std::function&&, Priority)>::__call_impl[abi:se190107] (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&&) @ 0x000000001320110f 9. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000132002ce 10. /build/src/IO/AsynchronousReadBufferFromFileDescriptor.cpp:62: DB::AsynchronousReadBufferFromFileDescriptor::asyncReadInto(char*, unsigned long, Priority) @ 0x00000000131f77d0 11. /build/src/IO/AsynchronousReadBufferFromFileDescriptor.cpp:100: DB::AsynchronousReadBufferFromFileDescriptor::nextImpl() @ 0x00000000131f7acb 12. /build/src/IO/ReadBuffer.h:60: DB::ReadBuffer::next() @ 0x000000000a148c7b 13. /build/src/IO/ReadBuffer.h:96: DB::CompressedReadBufferBase::readCompressedData(unsigned long&, unsigned long&, bool) @ 0x0000000017935e2b 14. /build/src/Compression/CompressedReadBufferFromFile.cpp:126: DB::CompressedReadBufferFromFile::readBig(char*, unsigned long) @ 0x0000000017938e9c 15. /build/src/DataTypes/Serializations/SerializationNumber.cpp:221: DB::SerializationNumber<_BitInt(8)>::deserializeBinaryBulk(DB::IColumn&, DB::ReadBuffer&, unsigned long, double) const @ 0x0000000013cdae58 16. /build/src/DataTypes/Serializations/ISerialization.cpp:147: DB::ISerialization::deserializeBinaryBulkWithMultipleStreams(COW::immutable_ptr&, unsigned long, DB::ISerialization::DeserializeBinaryBulkSettings&, std::shared_ptr&, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>*) const @ 0x0000000013c7b663 17. /build/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>>>*) @ 0x000000001648f4f9 18. /build/src/Storages/MergeTree/MergeTreeReaderCompactSingleBuffer.cpp:53: DB::MergeTreeReaderCompactSingleBuffer::readRows(unsigned long, unsigned long, bool, unsigned long, std::vector::immutable_ptr, std::allocator::immutable_ptr>>&) @ 0x00000000164a3ba0 19. /build/src/Storages/MergeTree/MergeTreeRangeReader.cpp:116: DB::MergeTreeRangeReader::DelayedStream::finalize(std::vector::immutable_ptr, std::allocator::immutable_ptr>>&) @ 0x0000000016497db1 20. /build/src/Storages/MergeTree/MergeTreeRangeReader.cpp:298: DB::MergeTreeRangeReader::startReadingChain(unsigned long, DB::MarkRanges&) @ 0x000000001649f129 21. /build/src/Storages/MergeTree/MergeTreeReadersChain.cpp:67: DB::MergeTreeReadersChain::read(unsigned long, DB::MarkRanges&) @ 0x00000000164b9dda 22. /build/src/Storages/MergeTree/MergeTreeReadTask.cpp:172: DB::MergeTreeReadTask::read() @ 0x00000000164b6300 23. /build/src/Storages/MergeTree/MergeTreeSelectAlgorithms.h:38: DB::MergeTreeThreadSelectAlgorithm::readFromTask(DB::MergeTreeReadTask&) @ 0x0000000016e3caac 24. /build/src/Storages/MergeTree/MergeTreeSelectProcessor.cpp:207: DB::MergeTreeSelectProcessor::read() @ 0x00000000164c0ba4 25. /build/src/Storages/MergeTree/MergeTreeSource.cpp:229: DB::MergeTreeSource::tryGenerate() @ 0x0000000016e43d69 26. /build/src/Processors/ISource.cpp:108: DB::ISource::work() @ 0x00000000169a21e7 27. /build/src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x00000000169bd00f 28. /build/src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x00000000169b2105 29. /build/src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeSingleThread(unsigned long) @ 0x00000000169b23be 30. /build/src/Processors/Executors/PipelineExecutor.cpp:416: void std::__function::__policy_invoker::__call_impl[abi:se190107]>(std::__function::__policy_storage const*) @ 0x00000000169b2e3f 31. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc6653 Job's origin stack trace: 0. /build/src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000000fc33b84 1. /build/src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000000fcc2ea7 2. /build/src/Common/ThreadPool.cpp:401: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fcc7f1c 3. /build/src/Common/ThreadPool.cpp:494: ThreadPoolImpl>::scheduleOrThrowOnError(std::function, Priority) @ 0x000000000fcc7a0e 4. /build/src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::spawnThreadsImpl() @ 0x00000000169b2c0c 5. /build/src/Processors/Executors/PipelineExecutor.cpp:394: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x00000000169b0ba7 6. /build/src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x00000000169b03f4 7. /build/src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:se190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169bfeab 8. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc3d92 9. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fcca080 10. ? @ 0x00007fbc6213eac3 11. ? @ 0x00007fbc621d0850 Job's origin stack trace: 0. /build/src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000000fc33b84 1. /build/src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000000fcc2ea7 2. /build/src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fcc535c 3. /build/src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000000fcc584d 4. /build/src/Common/ThreadPool.h:279: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x00000000169bf193 5. /build/src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x00000000169bf518 6. /build/src/Server/TCPHandler.cpp:1237: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x00000000168f1525 7. /build/src/Server/TCPHandler.cpp:678: DB::TCPHandler::runImpl() @ 0x00000000168e68e5 8. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 9. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 10. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 11. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 12. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 13. ? @ 0x00007fbc6213eac3 14. ? @ 0x00007fbc621d0850 2025.07.28 11:50:36.553088 [ 4260 ] {a54dfe6d-d30a-4423-9a1c-3eb74f5a9dd9} AsynchronousInsertQueue: Failed parsing for query 'INSERT INTO test_1.t_json_async_insert (data) FORMAT JSONAsObject' with query id 6712c1fb-4185-420c-9803-853cb6173304. DB::Exception: Cannot parse JSON object here: {"aaa"}: (at row 1) 2025.07.28 11:50:36.609745 [ 4508 ] {85681dbf-a662-48fd-9303-fd37f1d449a4} 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.6.10636.altinitytest (altinity build)) (from [::1]:52866) (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. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&) @ 0x000000000a10182b 4. /build/src/Functions/tupleHammingDistance.cpp:58: DB::FunctionTupleHammingDistance::getReturnTypeImpl(std::vector> const&) const @ 0x000000000e939df3 5. /build/src/Functions/IFunction.cpp:645: DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x0000000012d96b0c 6. /build/src/Functions/IFunction.cpp:577: DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x0000000012d9669c 7. /build/src/Functions/IFunction.cpp:606: DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x0000000012d96edc 8. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3544: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000014033cc9 9. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3838: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000014019a9e 10. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3980: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000014018e31 11. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:4304: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000014042fa7 12. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5605: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000014013749 13. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000140127f9 14. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000014011fce 15. /build/src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000001406ce8a 16. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000014973b42 17. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000001497268d 18. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000014974d24 19. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001492924b 20. /build/src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88641 21. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 22. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 23. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 24. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 25. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 26. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 27. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 28. ? @ 0x00007fbc6213eac3 29. ? @ 0x00007fbc621d0850 2025.07.28 11:50:36.615251 [ 4508 ] {} 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. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&) @ 0x000000000a10182b 4. /build/src/Functions/tupleHammingDistance.cpp:58: DB::FunctionTupleHammingDistance::getReturnTypeImpl(std::vector> const&) const @ 0x000000000e939df3 5. /build/src/Functions/IFunction.cpp:645: DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x0000000012d96b0c 6. /build/src/Functions/IFunction.cpp:577: DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x0000000012d9669c 7. /build/src/Functions/IFunction.cpp:606: DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x0000000012d96edc 8. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3544: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000014033cc9 9. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3838: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000014019a9e 10. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3980: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000014018e31 11. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:4304: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000014042fa7 12. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5605: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000014013749 13. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000140127f9 14. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000014011fce 15. /build/src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000001406ce8a 16. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000014973b42 17. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000001497268d 18. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000014974d24 19. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001492924b 20. /build/src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88641 21. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 22. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 23. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 24. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 25. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 26. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 27. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 28. ? @ 0x00007fbc6213eac3 29. ? @ 0x00007fbc621d0850 2025.07.28 11:50:36.650678 [ 4900 ] {6712c1fb-4185-420c-9803-853cb6173304} executeQuery: Code: 117. DB::Exception: Cannot parse JSON object here: {"aaa"}: (at row 1) : While executing WaitForAsyncInsert. (INCORRECT_DATA) (version 25.3.6.10636.altinitytest (altinity build)) (from [::1]:53240) (comment: 02421_new_type_json_async_insert.sh) (query 1, line 1) (in query: INSERT INTO t_json_async_insert FORMAT JSONAsObject ), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x000000000c25bc4b 4. /build/src/DataTypes/Serializations/SerializationJSON.cpp:299: DB::SerializationJSON::deserializeObject(DB::IColumn&, std::basic_string_view>, DB::FormatSettings const&) const @ 0x0000000013cbaf0d 5. /build/src/DataTypes/Serializations/SerializationJSON.cpp:393: DB::SerializationJSON::deserializeTextJSON(DB::IColumn&, DB::ReadBuffer&, DB::FormatSettings const&) const @ 0x0000000013cbabe6 6. /build/src/Processors/Formats/Impl/JSONAsStringRowInputFormat.cpp:52: DB::JSONAsRowInputFormat::readRow(std::vector::mutable_ptr, std::allocator::mutable_ptr>>&, DB::RowReadExtension&) @ 0x0000000016ac0869 7. /build/src/Processors/Formats/IRowInputFormat.cpp:143: DB::IRowInputFormat::read() @ 0x0000000016a1fc72 8. /build/src/Processors/Formats/IInputFormat.cpp:19: DB::IInputFormat::generate() @ 0x00000000169c5536 9. /build/src/Processors/ISource.cpp:139: DB::ISource::tryGenerate() @ 0x00000000169a24fa 10. /build/src/Processors/ISource.cpp:108: DB::ISource::work() @ 0x00000000169a21e7 11. /build/src/Processors/Executors/StreamingFormatExecutor.cpp:77: DB::StreamingFormatExecutor::execute() @ 0x00000000169c44ca 12. /build/src/Processors/Executors/StreamingFormatExecutor.cpp:58: DB::StreamingFormatExecutor::execute(DB::ReadBuffer&) @ 0x00000000169c431c 13. /build/src/Interpreters/AsynchronousInsertQueue.cpp:1085: DB::AsynchronousInsertQueue::processData(DB::AsynchronousInsertQueue::InsertQuery, std::unique_ptr>, std::shared_ptr, DB::AsynchronousInsertQueue::QueueShardFlushTimeHistory&) @ 0x00000000143e3843 14. /build/src/Interpreters/AsynchronousInsertQueue.cpp:319: void std::__function::__policy_invoker::__call_impl[abi:se190107]>, std::shared_ptr, unsigned long)::$_0, void ()>>(std::__function::__policy_storage const*) @ 0x00000000143e6d04 15. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc6653 16. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000000fccc4c3 17. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc3d92 18. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fcca080 19. ? @ 0x00007fbc6213eac3 20. ? @ 0x00007fbc621d0850 2025.07.28 11:50:36.691600 [ 4900 ] {} TCPHandler: Code: 117. DB::Exception: Cannot parse JSON object here: {"aaa"}: (at row 1) : While executing WaitForAsyncInsert. (INCORRECT_DATA), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x000000000c25bc4b 4. /build/src/DataTypes/Serializations/SerializationJSON.cpp:299: DB::SerializationJSON::deserializeObject(DB::IColumn&, std::basic_string_view>, DB::FormatSettings const&) const @ 0x0000000013cbaf0d 5. /build/src/DataTypes/Serializations/SerializationJSON.cpp:393: DB::SerializationJSON::deserializeTextJSON(DB::IColumn&, DB::ReadBuffer&, DB::FormatSettings const&) const @ 0x0000000013cbabe6 6. /build/src/Processors/Formats/Impl/JSONAsStringRowInputFormat.cpp:52: DB::JSONAsRowInputFormat::readRow(std::vector::mutable_ptr, std::allocator::mutable_ptr>>&, DB::RowReadExtension&) @ 0x0000000016ac0869 7. /build/src/Processors/Formats/IRowInputFormat.cpp:143: DB::IRowInputFormat::read() @ 0x0000000016a1fc72 8. /build/src/Processors/Formats/IInputFormat.cpp:19: DB::IInputFormat::generate() @ 0x00000000169c5536 9. /build/src/Processors/ISource.cpp:139: DB::ISource::tryGenerate() @ 0x00000000169a24fa 10. /build/src/Processors/ISource.cpp:108: DB::ISource::work() @ 0x00000000169a21e7 11. /build/src/Processors/Executors/StreamingFormatExecutor.cpp:77: DB::StreamingFormatExecutor::execute() @ 0x00000000169c44ca 12. /build/src/Processors/Executors/StreamingFormatExecutor.cpp:58: DB::StreamingFormatExecutor::execute(DB::ReadBuffer&) @ 0x00000000169c431c 13. /build/src/Interpreters/AsynchronousInsertQueue.cpp:1085: DB::AsynchronousInsertQueue::processData(DB::AsynchronousInsertQueue::InsertQuery, std::unique_ptr>, std::shared_ptr, DB::AsynchronousInsertQueue::QueueShardFlushTimeHistory&) @ 0x00000000143e3843 14. /build/src/Interpreters/AsynchronousInsertQueue.cpp:319: void std::__function::__policy_invoker::__call_impl[abi:se190107]>, std::shared_ptr, unsigned long)::$_0, void ()>>(std::__function::__policy_storage const*) @ 0x00000000143e6d04 15. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc6653 16. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000000fccc4c3 17. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc3d92 18. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fcca080 19. ? @ 0x00007fbc6213eac3 20. ? @ 0x00007fbc621d0850 2025.07.28 11:50:36.720837 [ 4508 ] {bbef96db-b4ba-4620-ba8b-3fbf43c45f50} 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.6.10636.altinitytest (altinity build)) (from [::1]:52866) (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. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception>&>(int, FormatStringHelperImpl::type, std::type_identity>&>::type>, String&&, std::basic_string_view>&) @ 0x000000000de9098b 4. /build/src/DataTypes/getLeastSupertype.cpp:69: std::shared_ptr DB::(anonymous namespace)::throwOrReturn<(DB::LeastSupertypeOnError)0, std::vector, std::allocator>>>(std::vector, std::allocator>> const&, std::basic_string_view>, int) @ 0x0000000013c6a73e 5. /build/src/DataTypes/getLeastSupertype.cpp:547: std::shared_ptr DB::getLeastSupertype<(DB::LeastSupertypeOnError)0>(std::vector, std::allocator>> const&) @ 0x0000000013c6dd15 6. /build/src/Functions/FunctionsComparison.h:1149: DB::FunctionComparison::executeGeneric(DB::ColumnWithTypeAndName const&, DB::ColumnWithTypeAndName const&) const @ 0x000000000db4a3f3 7. /build/src/Functions/FunctionsComparison.h:1429: DB::FunctionComparison::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000db31754 8. /build/src/Functions/IFunctionAdaptors.cpp:10: DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000012d995fa 9. /build/src/Functions/IFunction.cpp:353: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d93b52 10. /build/src/Functions/IFunction.cpp:420: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d95059 11. /build/src/Functions/IFunction.cpp:498: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d95c72 12. /build/src/Functions/IFunction.cpp:513: DB::IFunctionBase::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d96059 13. /build/src/Functions/tupleHammingDistance.cpp:122: DB::FunctionTupleHammingDistance::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000e93791c 14. /build/src/Functions/IFunction.h:437: DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000a069f2a 15. /build/src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000012d9965a 16. /build/src/Functions/IFunction.cpp:351: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d93b02 17. /build/src/Functions/IFunction.cpp:177: DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d93698 18. /build/src/Functions/IFunction.cpp:343: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d93aad 19. /build/src/Functions/IFunction.cpp:420: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d95059 20. /build/src/Functions/IFunction.cpp:498: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d95c72 21. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3567: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000014034494 22. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3838: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000014019a9e 23. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3980: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000014018e31 24. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:4304: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000014042fa7 25. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5605: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000014013749 26. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000140127f9 27. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000014011fce 28. /build/src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000001406ce8a 29. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000014973b42 30. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000001497268d 31. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000014974d24 2025.07.28 11:50:36.744075 [ 4508 ] {} 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. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception>&>(int, FormatStringHelperImpl::type, std::type_identity>&>::type>, String&&, std::basic_string_view>&) @ 0x000000000de9098b 4. /build/src/DataTypes/getLeastSupertype.cpp:69: std::shared_ptr DB::(anonymous namespace)::throwOrReturn<(DB::LeastSupertypeOnError)0, std::vector, std::allocator>>>(std::vector, std::allocator>> const&, std::basic_string_view>, int) @ 0x0000000013c6a73e 5. /build/src/DataTypes/getLeastSupertype.cpp:547: std::shared_ptr DB::getLeastSupertype<(DB::LeastSupertypeOnError)0>(std::vector, std::allocator>> const&) @ 0x0000000013c6dd15 6. /build/src/Functions/FunctionsComparison.h:1149: DB::FunctionComparison::executeGeneric(DB::ColumnWithTypeAndName const&, DB::ColumnWithTypeAndName const&) const @ 0x000000000db4a3f3 7. /build/src/Functions/FunctionsComparison.h:1429: DB::FunctionComparison::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000db31754 8. /build/src/Functions/IFunctionAdaptors.cpp:10: DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000012d995fa 9. /build/src/Functions/IFunction.cpp:353: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d93b52 10. /build/src/Functions/IFunction.cpp:420: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d95059 11. /build/src/Functions/IFunction.cpp:498: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d95c72 12. /build/src/Functions/IFunction.cpp:513: DB::IFunctionBase::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d96059 13. /build/src/Functions/tupleHammingDistance.cpp:122: DB::FunctionTupleHammingDistance::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000e93791c 14. /build/src/Functions/IFunction.h:437: DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000a069f2a 15. /build/src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000012d9965a 16. /build/src/Functions/IFunction.cpp:351: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d93b02 17. /build/src/Functions/IFunction.cpp:177: DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d93698 18. /build/src/Functions/IFunction.cpp:343: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d93aad 19. /build/src/Functions/IFunction.cpp:420: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d95059 20. /build/src/Functions/IFunction.cpp:498: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d95c72 21. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3567: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000014034494 22. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3838: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000014019a9e 23. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3980: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000014018e31 24. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:4304: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000014042fa7 25. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5605: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000014013749 26. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000140127f9 27. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000014011fce 28. /build/src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000001406ce8a 29. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000014973b42 30. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000001497268d 31. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000014974d24 2025.07.28 11:50:36.864031 [ 4508 ] {d945ad36-dafe-4a85-b290-2e9ee7e43565} 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.6.10636.altinitytest (altinity build)) (from [::1]:52866) (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. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception>&>(int, FormatStringHelperImpl::type, std::type_identity>&>::type>, String&&, std::basic_string_view>&) @ 0x000000000de9098b 4. /build/src/DataTypes/getLeastSupertype.cpp:69: std::shared_ptr DB::(anonymous namespace)::throwOrReturn<(DB::LeastSupertypeOnError)0, std::vector, std::allocator>>>(std::vector, std::allocator>> const&, std::basic_string_view>, int) @ 0x0000000013c6a73e 5. /build/src/DataTypes/getLeastSupertype.cpp:547: std::shared_ptr DB::getLeastSupertype<(DB::LeastSupertypeOnError)0>(std::vector, std::allocator>> const&) @ 0x0000000013c6dd15 6. /build/src/Functions/FunctionsComparison.h:1149: DB::FunctionComparison::executeGeneric(DB::ColumnWithTypeAndName const&, DB::ColumnWithTypeAndName const&) const @ 0x000000000db4a3f3 7. /build/src/Functions/FunctionsComparison.h:1429: DB::FunctionComparison::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000db31754 8. /build/src/Functions/IFunctionAdaptors.cpp:10: DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000012d995fa 9. /build/src/Functions/IFunction.cpp:353: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d93b52 10. /build/src/Functions/IFunction.cpp:420: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d95059 11. /build/src/Functions/IFunction.cpp:498: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d95c72 12. /build/src/Functions/IFunction.cpp:513: DB::IFunctionBase::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d96059 13. /build/src/Functions/tupleHammingDistance.cpp:122: DB::FunctionTupleHammingDistance::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000e93791c 14. /build/src/Functions/IFunction.h:437: DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000a069f2a 15. /build/src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000012d9965a 16. /build/src/Functions/IFunction.cpp:351: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d93b02 17. /build/src/Functions/IFunction.cpp:177: DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d93698 18. /build/src/Functions/IFunction.cpp:343: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d93aad 19. /build/src/Functions/IFunction.cpp:420: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d95059 20. /build/src/Functions/IFunction.cpp:498: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d95c72 21. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3567: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000014034494 22. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3838: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000014019a9e 23. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3980: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000014018e31 24. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:4304: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000014042fa7 25. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5605: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000014013749 26. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000140127f9 27. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000014011fce 28. /build/src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000001406ce8a 29. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000014973b42 30. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000001497268d 31. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000014974d24 2025.07.28 11:50:36.868889 [ 4508 ] {} 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. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception>&>(int, FormatStringHelperImpl::type, std::type_identity>&>::type>, String&&, std::basic_string_view>&) @ 0x000000000de9098b 4. /build/src/DataTypes/getLeastSupertype.cpp:69: std::shared_ptr DB::(anonymous namespace)::throwOrReturn<(DB::LeastSupertypeOnError)0, std::vector, std::allocator>>>(std::vector, std::allocator>> const&, std::basic_string_view>, int) @ 0x0000000013c6a73e 5. /build/src/DataTypes/getLeastSupertype.cpp:547: std::shared_ptr DB::getLeastSupertype<(DB::LeastSupertypeOnError)0>(std::vector, std::allocator>> const&) @ 0x0000000013c6dd15 6. /build/src/Functions/FunctionsComparison.h:1149: DB::FunctionComparison::executeGeneric(DB::ColumnWithTypeAndName const&, DB::ColumnWithTypeAndName const&) const @ 0x000000000db4a3f3 7. /build/src/Functions/FunctionsComparison.h:1429: DB::FunctionComparison::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000db31754 8. /build/src/Functions/IFunctionAdaptors.cpp:10: DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000012d995fa 9. /build/src/Functions/IFunction.cpp:353: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d93b52 10. /build/src/Functions/IFunction.cpp:420: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d95059 11. /build/src/Functions/IFunction.cpp:498: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d95c72 12. /build/src/Functions/IFunction.cpp:513: DB::IFunctionBase::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d96059 13. /build/src/Functions/tupleHammingDistance.cpp:122: DB::FunctionTupleHammingDistance::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000e93791c 14. /build/src/Functions/IFunction.h:437: DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000a069f2a 15. /build/src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000012d9965a 16. /build/src/Functions/IFunction.cpp:351: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d93b02 17. /build/src/Functions/IFunction.cpp:177: DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d93698 18. /build/src/Functions/IFunction.cpp:343: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d93aad 19. /build/src/Functions/IFunction.cpp:420: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d95059 20. /build/src/Functions/IFunction.cpp:498: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d95c72 21. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3567: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000014034494 22. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3838: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000014019a9e 23. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3980: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000014018e31 24. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:4304: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000014042fa7 25. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5605: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000014013749 26. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000140127f9 27. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000014011fce 28. /build/src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000001406ce8a 29. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000014973b42 30. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000001497268d 31. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000014974d24 2025.07.28 11:50:36.937689 [ 5146 ] {2951a620-a966-46eb-a20e-a6a3c0c6cc7f} executeQuery: Code: 47. DB::Exception: Unknown expression or function identifier `x` in scope x = 1. (UNKNOWN_IDENTIFIER) (version 25.3.6.10636.altinitytest (altinity build)) (from [::1]:53302) (comment: 02421_new_type_json_async_insert.sh) (query 1, line 1) (in query: SELECT count() FROM t_json_async_insert), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.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&&) @ 0x000000001404b3b9 4. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3771: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000001401b849 5. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3980: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000014018e31 6. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:2925: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000001402fcbd 7. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3838: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000014019a9e 8. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:209: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000001401270e 9. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000014011fce 10. /build/src/Planner/Utils.cpp:458: DB::buildFilterInfo(std::shared_ptr, std::shared_ptr const&, std::shared_ptr&, std::unordered_set, std::equal_to, std::allocator>) @ 0x0000000013fe8bcf 11. /build/src/Planner/PlannerJoinTree.cpp:535: DB::(anonymous namespace)::buildQueryPlanForTableExpression(std::shared_ptr, std::shared_ptr const&, DB::SelectQueryInfo const&, DB::SelectQueryOptions const&, std::shared_ptr&, bool, bool) @ 0x00000000149956d3 12. /build/src/Planner/PlannerJoinTree.cpp:2252: DB::buildJoinTreeQueryPlan(std::shared_ptr const&, DB::SelectQueryInfo const&, DB::SelectQueryOptions&, std::unordered_set, std::equal_to, std::allocator> const&, std::shared_ptr&) @ 0x000000001498e109 13. /build/src/Planner/Planner.cpp:1553: DB::Planner::buildPlanForQueryNode() @ 0x0000000014979dae 14. /build/src/Planner/Planner.cpp:1308: DB::Planner::buildQueryPlanIfNeeded() @ 0x000000001497685c 15. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:255: DB::InterpreterSelectQueryAnalyzer::getQueryPlan() @ 0x000000001497476d 16. /build/src/Interpreters/executeQuery.cpp:1405: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88806 17. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 18. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 19. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 20. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 21. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 22. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 23. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 24. ? @ 0x00007fbc6213eac3 25. ? @ 0x00007fbc621d0850 2025.07.28 11:50:36.983554 [ 5146 ] {} TCPHandler: Code: 47. DB::Exception: Unknown expression or function identifier `x` in scope x = 1. (UNKNOWN_IDENTIFIER), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.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&&) @ 0x000000001404b3b9 4. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3771: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000001401b849 5. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3980: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000014018e31 6. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:2925: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000001402fcbd 7. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3838: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000014019a9e 8. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:209: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000001401270e 9. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000014011fce 10. /build/src/Planner/Utils.cpp:458: DB::buildFilterInfo(std::shared_ptr, std::shared_ptr const&, std::shared_ptr&, std::unordered_set, std::equal_to, std::allocator>) @ 0x0000000013fe8bcf 11. /build/src/Planner/PlannerJoinTree.cpp:535: DB::(anonymous namespace)::buildQueryPlanForTableExpression(std::shared_ptr, std::shared_ptr const&, DB::SelectQueryInfo const&, DB::SelectQueryOptions const&, std::shared_ptr&, bool, bool) @ 0x00000000149956d3 12. /build/src/Planner/PlannerJoinTree.cpp:2252: DB::buildJoinTreeQueryPlan(std::shared_ptr const&, DB::SelectQueryInfo const&, DB::SelectQueryOptions&, std::unordered_set, std::equal_to, std::allocator> const&, std::shared_ptr&) @ 0x000000001498e109 13. /build/src/Planner/Planner.cpp:1553: DB::Planner::buildPlanForQueryNode() @ 0x0000000014979dae 14. /build/src/Planner/Planner.cpp:1308: DB::Planner::buildQueryPlanIfNeeded() @ 0x000000001497685c 15. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:255: DB::InterpreterSelectQueryAnalyzer::getQueryPlan() @ 0x000000001497476d 16. /build/src/Interpreters/executeQuery.cpp:1405: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88806 17. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 18. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 19. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 20. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 21. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 22. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 23. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 24. ? @ 0x00007fbc6213eac3 25. ? @ 0x00007fbc621d0850 2025.07.28 11:50:37.948771 [ 7244 ] {272573e1-2975-41b2-9ffe-caf468a3dbbb} AsynchronousInsertQueue: Failed parsing for query 'INSERT INTO test_1.t_json_async_insert (data) FORMAT JSONAsObject' with query id fc451aa7-8473-4924-b4b7-27d52b866063. DB::Exception: Cannot parse JSON object here: {"aaa"}: (at row 1) 2025.07.28 11:50:38.020365 [ 5980 ] {fc451aa7-8473-4924-b4b7-27d52b866063} executeQuery: Code: 117. DB::Exception: Cannot parse JSON object here: {"aaa"}: (at row 1) : While executing WaitForAsyncInsert. (INCORRECT_DATA) (version 25.3.6.10636.altinitytest (altinity build)) (from [::1]:53394) (comment: 02421_new_type_json_async_insert.sh) (query 1, line 1) (in query: INSERT INTO t_json_async_insert FORMAT JSONAsObject ), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x000000000c25bc4b 4. /build/src/DataTypes/Serializations/SerializationJSON.cpp:299: DB::SerializationJSON::deserializeObject(DB::IColumn&, std::basic_string_view>, DB::FormatSettings const&) const @ 0x0000000013cbaf0d 5. /build/src/DataTypes/Serializations/SerializationJSON.cpp:393: DB::SerializationJSON::deserializeTextJSON(DB::IColumn&, DB::ReadBuffer&, DB::FormatSettings const&) const @ 0x0000000013cbabe6 6. /build/src/Processors/Formats/Impl/JSONAsStringRowInputFormat.cpp:52: DB::JSONAsRowInputFormat::readRow(std::vector::mutable_ptr, std::allocator::mutable_ptr>>&, DB::RowReadExtension&) @ 0x0000000016ac0869 7. /build/src/Processors/Formats/IRowInputFormat.cpp:143: DB::IRowInputFormat::read() @ 0x0000000016a1fc72 8. /build/src/Processors/Formats/IInputFormat.cpp:19: DB::IInputFormat::generate() @ 0x00000000169c5536 9. /build/src/Processors/ISource.cpp:139: DB::ISource::tryGenerate() @ 0x00000000169a24fa 10. /build/src/Processors/ISource.cpp:108: DB::ISource::work() @ 0x00000000169a21e7 11. /build/src/Processors/Executors/StreamingFormatExecutor.cpp:77: DB::StreamingFormatExecutor::execute() @ 0x00000000169c44ca 12. /build/src/Processors/Executors/StreamingFormatExecutor.cpp:58: DB::StreamingFormatExecutor::execute(DB::ReadBuffer&) @ 0x00000000169c431c 13. /build/src/Interpreters/AsynchronousInsertQueue.cpp:1085: DB::AsynchronousInsertQueue::processData(DB::AsynchronousInsertQueue::InsertQuery, std::unique_ptr>, std::shared_ptr, DB::AsynchronousInsertQueue::QueueShardFlushTimeHistory&) @ 0x00000000143e3843 14. /build/src/Interpreters/AsynchronousInsertQueue.cpp:319: void std::__function::__policy_invoker::__call_impl[abi:se190107]>, std::shared_ptr, unsigned long)::$_0, void ()>>(std::__function::__policy_storage const*) @ 0x00000000143e6d04 15. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc6653 16. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000000fccc4c3 17. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc3d92 18. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fcca080 19. ? @ 0x00007fbc6213eac3 20. ? @ 0x00007fbc621d0850 2025.07.28 11:50:38.023225 [ 5980 ] {} TCPHandler: Code: 117. DB::Exception: Cannot parse JSON object here: {"aaa"}: (at row 1) : While executing WaitForAsyncInsert. (INCORRECT_DATA), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x000000000c25bc4b 4. /build/src/DataTypes/Serializations/SerializationJSON.cpp:299: DB::SerializationJSON::deserializeObject(DB::IColumn&, std::basic_string_view>, DB::FormatSettings const&) const @ 0x0000000013cbaf0d 5. /build/src/DataTypes/Serializations/SerializationJSON.cpp:393: DB::SerializationJSON::deserializeTextJSON(DB::IColumn&, DB::ReadBuffer&, DB::FormatSettings const&) const @ 0x0000000013cbabe6 6. /build/src/Processors/Formats/Impl/JSONAsStringRowInputFormat.cpp:52: DB::JSONAsRowInputFormat::readRow(std::vector::mutable_ptr, std::allocator::mutable_ptr>>&, DB::RowReadExtension&) @ 0x0000000016ac0869 7. /build/src/Processors/Formats/IRowInputFormat.cpp:143: DB::IRowInputFormat::read() @ 0x0000000016a1fc72 8. /build/src/Processors/Formats/IInputFormat.cpp:19: DB::IInputFormat::generate() @ 0x00000000169c5536 9. /build/src/Processors/ISource.cpp:139: DB::ISource::tryGenerate() @ 0x00000000169a24fa 10. /build/src/Processors/ISource.cpp:108: DB::ISource::work() @ 0x00000000169a21e7 11. /build/src/Processors/Executors/StreamingFormatExecutor.cpp:77: DB::StreamingFormatExecutor::execute() @ 0x00000000169c44ca 12. /build/src/Processors/Executors/StreamingFormatExecutor.cpp:58: DB::StreamingFormatExecutor::execute(DB::ReadBuffer&) @ 0x00000000169c431c 13. /build/src/Interpreters/AsynchronousInsertQueue.cpp:1085: DB::AsynchronousInsertQueue::processData(DB::AsynchronousInsertQueue::InsertQuery, std::unique_ptr>, std::shared_ptr, DB::AsynchronousInsertQueue::QueueShardFlushTimeHistory&) @ 0x00000000143e3843 14. /build/src/Interpreters/AsynchronousInsertQueue.cpp:319: void std::__function::__policy_invoker::__call_impl[abi:se190107]>, std::shared_ptr, unsigned long)::$_0, void ()>>(std::__function::__policy_storage const*) @ 0x00000000143e6d04 15. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc6653 16. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000000fccc4c3 17. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc3d92 18. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fcca080 19. ? @ 0x00007fbc6213eac3 20. ? @ 0x00007fbc621d0850 2025.07.28 11:50:38.398818 [ 3287 ] {7e3a3fee-651b-4d30-bb3c-d70f254f0bf8} executeQuery: Code: 47. DB::Exception: Unknown expression or function identifier `x` in scope x = 1. (UNKNOWN_IDENTIFIER) (version 25.3.6.10636.altinitytest (altinity build)) (from [::1]:53470) (comment: 02421_new_type_json_async_insert.sh) (query 1, line 1) (in query: SELECT data.k1 FROM t_json_async_insert ORDER BY data.k1), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.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&&) @ 0x000000001404b3b9 4. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3771: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000001401b849 5. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3980: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000014018e31 6. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:2925: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000001402fcbd 7. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3838: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000014019a9e 8. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:209: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000001401270e 9. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000014011fce 10. /build/src/Planner/Utils.cpp:458: DB::buildFilterInfo(std::shared_ptr, std::shared_ptr const&, std::shared_ptr&, std::unordered_set, std::equal_to, std::allocator>) @ 0x0000000013fe8bcf 11. /build/src/Planner/PlannerJoinTree.cpp:535: DB::(anonymous namespace)::buildQueryPlanForTableExpression(std::shared_ptr, std::shared_ptr const&, DB::SelectQueryInfo const&, DB::SelectQueryOptions const&, std::shared_ptr&, bool, bool) @ 0x00000000149956d3 12. /build/src/Planner/PlannerJoinTree.cpp:2252: DB::buildJoinTreeQueryPlan(std::shared_ptr const&, DB::SelectQueryInfo const&, DB::SelectQueryOptions&, std::unordered_set, std::equal_to, std::allocator> const&, std::shared_ptr&) @ 0x000000001498e109 13. /build/src/Planner/Planner.cpp:1553: DB::Planner::buildPlanForQueryNode() @ 0x0000000014979dae 14. /build/src/Planner/Planner.cpp:1308: DB::Planner::buildQueryPlanIfNeeded() @ 0x000000001497685c 15. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:255: DB::InterpreterSelectQueryAnalyzer::getQueryPlan() @ 0x000000001497476d 16. /build/src/Interpreters/executeQuery.cpp:1405: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88806 17. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 18. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 19. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 20. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 21. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 22. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 23. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 24. ? @ 0x00007fbc6213eac3 25. ? @ 0x00007fbc621d0850 2025.07.28 11:50:38.411632 [ 3287 ] {} TCPHandler: Code: 47. DB::Exception: Unknown expression or function identifier `x` in scope x = 1. (UNKNOWN_IDENTIFIER), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.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&&) @ 0x000000001404b3b9 4. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3771: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000001401b849 5. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3980: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000014018e31 6. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:2925: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000001402fcbd 7. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3838: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000014019a9e 8. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:209: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000001401270e 9. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000014011fce 10. /build/src/Planner/Utils.cpp:458: DB::buildFilterInfo(std::shared_ptr, std::shared_ptr const&, std::shared_ptr&, std::unordered_set, std::equal_to, std::allocator>) @ 0x0000000013fe8bcf 11. /build/src/Planner/PlannerJoinTree.cpp:535: DB::(anonymous namespace)::buildQueryPlanForTableExpression(std::shared_ptr, std::shared_ptr const&, DB::SelectQueryInfo const&, DB::SelectQueryOptions const&, std::shared_ptr&, bool, bool) @ 0x00000000149956d3 12. /build/src/Planner/PlannerJoinTree.cpp:2252: DB::buildJoinTreeQueryPlan(std::shared_ptr const&, DB::SelectQueryInfo const&, DB::SelectQueryOptions&, std::unordered_set, std::equal_to, std::allocator> const&, std::shared_ptr&) @ 0x000000001498e109 13. /build/src/Planner/Planner.cpp:1553: DB::Planner::buildPlanForQueryNode() @ 0x0000000014979dae 14. /build/src/Planner/Planner.cpp:1308: DB::Planner::buildQueryPlanIfNeeded() @ 0x000000001497685c 15. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:255: DB::InterpreterSelectQueryAnalyzer::getQueryPlan() @ 0x000000001497476d 16. /build/src/Interpreters/executeQuery.cpp:1405: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88806 17. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 18. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 19. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 20. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 21. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 22. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 23. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 24. ? @ 0x00007fbc6213eac3 25. ? @ 0x00007fbc621d0850 2025.07.28 11:50:39.422403 [ 4587 ] {d9362b7c-a70c-4dde-be31-f77d08e882b3} executeQuery: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=818, jobs=778). (CANNOT_SCHEDULE_TASK) (version 25.3.6.10636.altinitytest (altinity build)) (from [::ffff:127.0.0.1]:59486) (comment: 03165_string_functions_with_token_text_indexes.sql) (query 80, line 221) (in query: SELECT `__table1`.`id` AS `id`, `__table1`.`message` AS `message` FROM `test_7`.`03165_token_ft` AS `__table1` WHERE multiSearchAny(`__table1`.`message`, _CAST([' wx ', ' yz '], 'Array(String)'))), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000fccaeeb 4. /build/src/Common/ThreadPool.cpp:275: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000fccacb3 5. /build/src/Common/ThreadPool.cpp:323: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fcc4ffc 6. /build/src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000000fcc584d 7. /build/src/Common/ThreadPool.h:279: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x00000000169bf193 8. /build/src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x00000000169bf518 9. /build/src/Server/TCPHandler.cpp:1237: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x00000000168f1525 10. /build/src/Server/TCPHandler.cpp:678: DB::TCPHandler::runImpl() @ 0x00000000168e68e5 11. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 12. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 13. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 14. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 15. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 16. ? @ 0x00007fbc6213eac3 17. ? @ 0x00007fbc621d0850 2025.07.28 11:50:39.434585 [ 4587 ] {} TCPHandler: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=818, jobs=778). (CANNOT_SCHEDULE_TASK), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000fccaeeb 4. /build/src/Common/ThreadPool.cpp:275: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000fccacb3 5. /build/src/Common/ThreadPool.cpp:323: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fcc4ffc 6. /build/src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000000fcc584d 7. /build/src/Common/ThreadPool.h:279: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x00000000169bf193 8. /build/src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x00000000169bf518 9. /build/src/Server/TCPHandler.cpp:1237: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x00000000168f1525 10. /build/src/Server/TCPHandler.cpp:678: DB::TCPHandler::runImpl() @ 0x00000000168e68e5 11. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 12. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 13. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 14. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 15. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 16. ? @ 0x00007fbc6213eac3 17. ? @ 0x00007fbc621d0850 2025.07.28 11:50:39.443787 [ 4526 ] {e8abecf7-a2dd-45c7-9d54-2903cf4cfaf4} executeQuery: Code: 439. DB::Exception: Received from 127.0.0.8:9000. DB::Exception: Cannot schedule a task: fault injected (threads=818, jobs=778). Stack trace: 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000fccaeeb 4. /build/src/Common/ThreadPool.cpp:275: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000fccacb3 5. /build/src/Common/ThreadPool.cpp:323: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fcc4ffc 6. /build/src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000000fcc584d 7. /build/src/Common/ThreadPool.h:279: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x00000000169bf193 8. /build/src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x00000000169bf518 9. /build/src/Server/TCPHandler.cpp:1237: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x00000000168f1525 10. /build/src/Server/TCPHandler.cpp:678: DB::TCPHandler::runImpl() @ 0x00000000168e68e5 11. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 12. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 13. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 14. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 15. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 16. ? @ 0x00007fbc6213eac3 17. ? @ 0x00007fbc621d0850 : While executing Remote. (CANNOT_SCHEDULE_TASK) (version 25.3.6.10636.altinitytest (altinity build)) (from [::1]:59716) (comment: 03165_string_functions_with_token_text_indexes.sql) (query 80, line 221) (in query: SELECT * FROM 03165_token_ft WHERE multiSearchAny(message, [' wx ', ' yz ']);), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:111: DB::readException(DB::ReadBuffer&, String const&, bool) @ 0x000000000fc6e157 3. /build/src/Client/Connection.cpp:1445: DB::Connection::receiveException() const @ 0x00000000167d4127 4. /build/src/Client/Connection.cpp:1274: DB::Connection::receivePacket() @ 0x00000000167db312 5. /build/src/Client/MultiplexedConnections.cpp:380: DB::MultiplexedConnections::receivePacketUnlocked(std::function) @ 0x00000000168163a9 6. /build/src/QueryPipeline/RemoteQueryExecutorReadContext.cpp:67: DB::RemoteQueryExecutorReadContext::Task::run(std::function, std::function) @ 0x0000000013bd23fe 7. /build/src/Common/AsyncTaskExecutor.cpp:89: DB::AsyncTaskExecutor::Routine::operator()(std::function) @ 0x0000000013bd1892 8. /build/src/Common/Fiber.h:76: boost::context::detail::fiber_record>::run(void*) @ 0x0000000013bd16fa 9. /build/contrib/boost/boost/context/fiber_fcontext.hpp:97: void boost::context::detail::fiber_entry>>(boost::context::detail::transfer_t) @ 0x0000000013bd1621 2025.07.28 11:50:39.452204 [ 4526 ] {} TCPHandler: Code: 439. DB::Exception: Received from 127.0.0.8:9000. DB::Exception: Cannot schedule a task: fault injected (threads=818, jobs=778). Stack trace: 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000fccaeeb 4. /build/src/Common/ThreadPool.cpp:275: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000fccacb3 5. /build/src/Common/ThreadPool.cpp:323: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fcc4ffc 6. /build/src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000000fcc584d 7. /build/src/Common/ThreadPool.h:279: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x00000000169bf193 8. /build/src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x00000000169bf518 9. /build/src/Server/TCPHandler.cpp:1237: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x00000000168f1525 10. /build/src/Server/TCPHandler.cpp:678: DB::TCPHandler::runImpl() @ 0x00000000168e68e5 11. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 12. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 13. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 14. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 15. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 16. ? @ 0x00007fbc6213eac3 17. ? @ 0x00007fbc621d0850 : While executing Remote. (CANNOT_SCHEDULE_TASK), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:111: DB::readException(DB::ReadBuffer&, String const&, bool) @ 0x000000000fc6e157 3. /build/src/Client/Connection.cpp:1445: DB::Connection::receiveException() const @ 0x00000000167d4127 4. /build/src/Client/Connection.cpp:1274: DB::Connection::receivePacket() @ 0x00000000167db312 5. /build/src/Client/MultiplexedConnections.cpp:380: DB::MultiplexedConnections::receivePacketUnlocked(std::function) @ 0x00000000168163a9 6. /build/src/QueryPipeline/RemoteQueryExecutorReadContext.cpp:67: DB::RemoteQueryExecutorReadContext::Task::run(std::function, std::function) @ 0x0000000013bd23fe 7. /build/src/Common/AsyncTaskExecutor.cpp:89: DB::AsyncTaskExecutor::Routine::operator()(std::function) @ 0x0000000013bd1892 8. /build/src/Common/Fiber.h:76: boost::context::detail::fiber_record>::run(void*) @ 0x0000000013bd16fa 9. /build/contrib/boost/boost/context/fiber_fcontext.hpp:97: void boost::context::detail::fiber_entry>>(boost::context::detail::transfer_t) @ 0x0000000013bd1621 Job's origin stack trace: 0. /build/src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000000fc33b84 1. /build/src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000000fcc2ea7 2. /build/src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fcc535c 3. /build/src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000000fcc584d 4. /build/src/Common/ThreadPool.h:279: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x00000000169bf193 5. /build/src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x00000000169bf518 6. /build/src/Server/TCPHandler.cpp:1237: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x00000000168f1525 7. /build/src/Server/TCPHandler.cpp:678: DB::TCPHandler::runImpl() @ 0x00000000168e68e5 8. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 9. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 10. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 11. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 12. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 13. ? @ 0x00007fbc6213eac3 14. ? @ 0x00007fbc621d0850 2025.07.28 11:50:39.484027 [ 4462 ] {e744ddcf-e3cd-44b7-869d-53f29da477d9} executeQuery: Code: 210. DB::NetException: Connection reset by peer, while writing to socket ([::ffff:127.0.0.7]:9000 -> [::ffff:127.0.0.1]:43886). (NETWORK_ERROR) (version 25.3.6.10636.altinitytest (altinity build)) (from [::ffff:127.0.0.1]:43886) (comment: 03165_string_functions_with_token_text_indexes.sql) (query 80, line 221) (in query: SELECT `__table1`.`id` AS `id`, `__table1`.`message` AS `message` FROM `test_7`.`03165_token_ft` AS `__table1` WHERE multiSearchAny(`__table1`.`message`, _CAST([' wx ', ' yz '], 'Array(String)'))), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::NetException::NetException(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&) @ 0x000000000fd50fb5 3. /build/src/IO/WriteBufferFromPocoSocket.cpp:160: DB::WriteBufferFromPocoSocket::nextImpl() @ 0x000000000fd523f1 4. /build/src/IO/WriteBuffer.h:53: DB::WriteBuffer::next() @ 0x000000000a0755be 5. /build/src/Server/TCPHandler.cpp:1422: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x00000000168f181c 6. /build/src/Server/TCPHandler.cpp:678: DB::TCPHandler::runImpl() @ 0x00000000168e68e5 7. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 8. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 9. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 10. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 11. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 12. ? @ 0x00007fbc6213eac3 13. ? @ 0x00007fbc621d0850 2025.07.28 11:50:39.534186 [ 4462 ] {} TCPHandler: Code: 210. DB::NetException: Connection reset by peer, while writing to socket ([::ffff:127.0.0.7]:9000 -> [::ffff:127.0.0.1]:43886). (NETWORK_ERROR), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::NetException::NetException(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&) @ 0x000000000fd50fb5 3. /build/src/IO/WriteBufferFromPocoSocket.cpp:160: DB::WriteBufferFromPocoSocket::nextImpl() @ 0x000000000fd523f1 4. /build/src/IO/WriteBuffer.h:53: DB::WriteBuffer::next() @ 0x000000000a0755be 5. /build/src/Server/TCPHandler.cpp:1422: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x00000000168f181c 6. /build/src/Server/TCPHandler.cpp:678: DB::TCPHandler::runImpl() @ 0x00000000168e68e5 7. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 8. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 9. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 10. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 11. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 12. ? @ 0x00007fbc6213eac3 13. ? @ 0x00007fbc621d0850 2025.07.28 11:50:42.607964 [ 6138 ] {0ef20b06-5809-43fe-8ebd-0bbd464a5022} executeQuery: Code: 439. DB::Exception: Cannot schedule a task: failed to start the thread (threads=1, jobs=1). (CANNOT_SCHEDULE_TASK) (version 25.3.6.10636.altinitytest (altinity build)) (from [::1]:59436) (comment: 02125_lz4_compression_bug_Values.sh) (query 1, line 1) (in query: INSERT INTO file SELECT * FROM numbers(100000)), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000fccaeeb 4. /build/src/Common/ThreadPool.cpp:275: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000fccc813 5. /build/src/Common/ThreadPool.cpp:308: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fcc8286 6. /build/src/Common/ThreadPool.cpp:494: ThreadPoolImpl>::scheduleOrThrowOnError(std::function, Priority) @ 0x000000000fcc7a0e 7. /build/src/Processors/Formats/Impl/ParallelFormattingOutputFormat.h:296: DB::ParallelFormattingOutputFormat::scheduleFormatterThreadForUnitWithNumber(unsigned long, unsigned long) @ 0x0000000016b1aa05 8. /build/src/Processors/Formats/Impl/ParallelFormattingOutputFormat.cpp:99: DB::ParallelFormattingOutputFormat::addChunk(DB::Chunk, DB::ParallelFormattingOutputFormat::ProcessingUnitType, bool) @ 0x0000000016b19bbc 9. /build/src/Processors/Formats/Impl/ParallelFormattingOutputFormat.h:157: DB::ParallelFormattingOutputFormat::consume(DB::Chunk) @ 0x0000000016b1b029 10. /build/src/Processors/Formats/IOutputFormat.cpp:146: DB::IOutputFormat::write(DB::Block const&) @ 0x00000000169c83a3 11. /build/src/Storages/StorageFile.cpp:1840: DB::StorageFileSink::consume(DB::Chunk&) @ 0x0000000015d9d830 12. /build/src/Processors/Sinks/SinkToStorage.cpp:10: DB::SinkToStorage::onConsume(DB::Chunk) @ 0x0000000016cee093 13. /build/src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: void std::__function::__policy_invoker::__call_impl[abi:se190107]>(std::__function::__policy_storage const*) @ 0x0000000016c0ad89 14. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000016c0abf5 15. /build/src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: DB::ExceptionKeepingTransform::work() @ 0x0000000016c0a6fe 16. /build/src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x00000000169bd00f 17. /build/src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x00000000169b2105 18. /build/src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeSingleThread(unsigned long) @ 0x00000000169b23be 19. /build/src/Processors/Executors/PipelineExecutor.cpp:416: void std::__function::__policy_invoker::__call_impl[abi:se190107]>(std::__function::__policy_storage const*) @ 0x00000000169b2e3f 20. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc6653 21. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000000fccc4c3 22. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc3d92 23. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fcca080 24. ? @ 0x00007fbc6213eac3 25. ? @ 0x00007fbc621d0850 2025.07.28 11:50:42.743152 [ 6138 ] {} 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. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000fccaeeb 4. /build/src/Common/ThreadPool.cpp:275: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000fccc813 5. /build/src/Common/ThreadPool.cpp:308: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fcc8286 6. /build/src/Common/ThreadPool.cpp:494: ThreadPoolImpl>::scheduleOrThrowOnError(std::function, Priority) @ 0x000000000fcc7a0e 7. /build/src/Processors/Formats/Impl/ParallelFormattingOutputFormat.h:296: DB::ParallelFormattingOutputFormat::scheduleFormatterThreadForUnitWithNumber(unsigned long, unsigned long) @ 0x0000000016b1aa05 8. /build/src/Processors/Formats/Impl/ParallelFormattingOutputFormat.cpp:99: DB::ParallelFormattingOutputFormat::addChunk(DB::Chunk, DB::ParallelFormattingOutputFormat::ProcessingUnitType, bool) @ 0x0000000016b19bbc 9. /build/src/Processors/Formats/Impl/ParallelFormattingOutputFormat.h:157: DB::ParallelFormattingOutputFormat::consume(DB::Chunk) @ 0x0000000016b1b029 10. /build/src/Processors/Formats/IOutputFormat.cpp:146: DB::IOutputFormat::write(DB::Block const&) @ 0x00000000169c83a3 11. /build/src/Storages/StorageFile.cpp:1840: DB::StorageFileSink::consume(DB::Chunk&) @ 0x0000000015d9d830 12. /build/src/Processors/Sinks/SinkToStorage.cpp:10: DB::SinkToStorage::onConsume(DB::Chunk) @ 0x0000000016cee093 13. /build/src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: void std::__function::__policy_invoker::__call_impl[abi:se190107]>(std::__function::__policy_storage const*) @ 0x0000000016c0ad89 14. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000016c0abf5 15. /build/src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: DB::ExceptionKeepingTransform::work() @ 0x0000000016c0a6fe 16. /build/src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x00000000169bd00f 17. /build/src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x00000000169b2105 18. /build/src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeSingleThread(unsigned long) @ 0x00000000169b23be 19. /build/src/Processors/Executors/PipelineExecutor.cpp:416: void std::__function::__policy_invoker::__call_impl[abi:se190107]>(std::__function::__policy_storage const*) @ 0x00000000169b2e3f 20. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc6653 21. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000000fccc4c3 22. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc3d92 23. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fcca080 24. ? @ 0x00007fbc6213eac3 25. ? @ 0x00007fbc621d0850 Job's origin stack trace: 0. /build/src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000000fc33b84 1. /build/src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000000fcc2ea7 2. /build/src/Common/ThreadPool.cpp:401: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fcc7f1c 3. /build/src/Common/ThreadPool.cpp:494: ThreadPoolImpl>::scheduleOrThrowOnError(std::function, Priority) @ 0x000000000fcc7a0e 4. /build/src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::spawnThreadsImpl() @ 0x00000000169b2c0c 5. /build/src/Processors/Executors/PipelineExecutor.cpp:394: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x00000000169b0ba7 6. /build/src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x00000000169b03f4 7. /build/src/Processors/Executors/CompletedPipelineExecutor.cpp:42: void std::__function::__policy_invoker::__call_impl[abi:se190107]::ThreadFromGlobalPoolImpl(DB::CompletedPipelineExecutor::execute()::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169af7e1 8. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc3d92 9. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fcca080 10. ? @ 0x00007fbc6213eac3 11. ? @ 0x00007fbc621d0850 Job's origin stack trace: 0. /build/src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000000fc33b84 1. /build/src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000000fcc2ea7 2. /build/src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fcc535c 3. /build/src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000000fcc584d 4. /build/src/Common/ThreadPool.h:279: DB::CompletedPipelineExecutor::execute() @ 0x00000000169af267 5. /build/src/Server/TCPHandler.cpp:707: DB::TCPHandler::runImpl() @ 0x00000000168e6b2e 6. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 7. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 8. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 9. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 10. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 11. ? @ 0x00007fbc6213eac3 12. ? @ 0x00007fbc621d0850 2025.07.28 11:50:46.310109 [ 11826 ] {9c02ccaf-3c01-493a-adec-61278afbd553} executeQuery: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=2, jobs=0). (CANNOT_SCHEDULE_TASK) (version 25.3.6.10636.altinitytest (altinity build)) (from [::1]:59690) (comment: 02125_lz4_compression_bug_Values.sh) (query 1, line 1) (in query: INSERT INTO file SELECT * FROM numbers(2500000)), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000fccaeeb 4. /build/src/Common/ThreadPool.cpp:275: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000fccc813 5. /build/src/Common/ThreadPool.cpp:323: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fcc7bbc 6. /build/src/Common/ThreadPool.cpp:494: ThreadPoolImpl>::scheduleOrThrowOnError(std::function, Priority) @ 0x000000000fcc7a0e 7. /build/src/Processors/Formats/Impl/ParallelFormattingOutputFormat.h:296: DB::ParallelFormattingOutputFormat::scheduleFormatterThreadForUnitWithNumber(unsigned long, unsigned long) @ 0x0000000016b1aa05 8. /build/src/Processors/Formats/Impl/ParallelFormattingOutputFormat.cpp:99: DB::ParallelFormattingOutputFormat::addChunk(DB::Chunk, DB::ParallelFormattingOutputFormat::ProcessingUnitType, bool) @ 0x0000000016b19bbc 9. /build/src/Processors/Formats/Impl/ParallelFormattingOutputFormat.h:157: DB::ParallelFormattingOutputFormat::consume(DB::Chunk) @ 0x0000000016b1b029 10. /build/src/Processors/Formats/IOutputFormat.cpp:146: DB::IOutputFormat::write(DB::Block const&) @ 0x00000000169c83a3 11. /build/src/Storages/StorageFile.cpp:1840: DB::StorageFileSink::consume(DB::Chunk&) @ 0x0000000015d9d830 12. /build/src/Processors/Sinks/SinkToStorage.cpp:10: DB::SinkToStorage::onConsume(DB::Chunk) @ 0x0000000016cee093 13. /build/src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: void std::__function::__policy_invoker::__call_impl[abi:se190107]>(std::__function::__policy_storage const*) @ 0x0000000016c0ad89 14. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000016c0abf5 15. /build/src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: DB::ExceptionKeepingTransform::work() @ 0x0000000016c0a6fe 16. /build/src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x00000000169bd00f 17. /build/src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x00000000169b2105 18. /build/src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeSingleThread(unsigned long) @ 0x00000000169b23be 19. /build/src/Processors/Executors/PipelineExecutor.cpp:416: void std::__function::__policy_invoker::__call_impl[abi:se190107]>(std::__function::__policy_storage const*) @ 0x00000000169b2e3f 20. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc6653 21. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000000fccc4c3 22. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc3d92 23. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fcca080 24. ? @ 0x00007fbc6213eac3 25. ? @ 0x00007fbc621d0850 2025.07.28 11:50:46.426177 [ 11826 ] {} TCPHandler: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=2, jobs=0). (CANNOT_SCHEDULE_TASK), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000fccaeeb 4. /build/src/Common/ThreadPool.cpp:275: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000fccc813 5. /build/src/Common/ThreadPool.cpp:323: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fcc7bbc 6. /build/src/Common/ThreadPool.cpp:494: ThreadPoolImpl>::scheduleOrThrowOnError(std::function, Priority) @ 0x000000000fcc7a0e 7. /build/src/Processors/Formats/Impl/ParallelFormattingOutputFormat.h:296: DB::ParallelFormattingOutputFormat::scheduleFormatterThreadForUnitWithNumber(unsigned long, unsigned long) @ 0x0000000016b1aa05 8. /build/src/Processors/Formats/Impl/ParallelFormattingOutputFormat.cpp:99: DB::ParallelFormattingOutputFormat::addChunk(DB::Chunk, DB::ParallelFormattingOutputFormat::ProcessingUnitType, bool) @ 0x0000000016b19bbc 9. /build/src/Processors/Formats/Impl/ParallelFormattingOutputFormat.h:157: DB::ParallelFormattingOutputFormat::consume(DB::Chunk) @ 0x0000000016b1b029 10. /build/src/Processors/Formats/IOutputFormat.cpp:146: DB::IOutputFormat::write(DB::Block const&) @ 0x00000000169c83a3 11. /build/src/Storages/StorageFile.cpp:1840: DB::StorageFileSink::consume(DB::Chunk&) @ 0x0000000015d9d830 12. /build/src/Processors/Sinks/SinkToStorage.cpp:10: DB::SinkToStorage::onConsume(DB::Chunk) @ 0x0000000016cee093 13. /build/src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: void std::__function::__policy_invoker::__call_impl[abi:se190107]>(std::__function::__policy_storage const*) @ 0x0000000016c0ad89 14. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000016c0abf5 15. /build/src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: DB::ExceptionKeepingTransform::work() @ 0x0000000016c0a6fe 16. /build/src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x00000000169bd00f 17. /build/src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x00000000169b2105 18. /build/src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeSingleThread(unsigned long) @ 0x00000000169b23be 19. /build/src/Processors/Executors/PipelineExecutor.cpp:416: void std::__function::__policy_invoker::__call_impl[abi:se190107]>(std::__function::__policy_storage const*) @ 0x00000000169b2e3f 20. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc6653 21. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000000fccc4c3 22. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc3d92 23. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fcca080 24. ? @ 0x00007fbc6213eac3 25. ? @ 0x00007fbc621d0850 Job's origin stack trace: 0. /build/src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000000fc33b84 1. /build/src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000000fcc2ea7 2. /build/src/Common/ThreadPool.cpp:401: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fcc7f1c 3. /build/src/Common/ThreadPool.cpp:494: ThreadPoolImpl>::scheduleOrThrowOnError(std::function, Priority) @ 0x000000000fcc7a0e 4. /build/src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::spawnThreadsImpl() @ 0x00000000169b2c0c 5. /build/src/Processors/Executors/PipelineExecutor.cpp:394: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x00000000169b0ba7 6. /build/src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x00000000169b03f4 7. /build/src/Processors/Executors/CompletedPipelineExecutor.cpp:42: void std::__function::__policy_invoker::__call_impl[abi:se190107]::ThreadFromGlobalPoolImpl(DB::CompletedPipelineExecutor::execute()::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169af7e1 8. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc3d92 9. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fcca080 10. ? @ 0x00007fbc6213eac3 11. ? @ 0x00007fbc621d0850 Job's origin stack trace: 0. /build/src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000000fc33b84 1. /build/src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000000fcc2ea7 2. /build/src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fcc535c 3. /build/src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000000fcc584d 4. /build/src/Common/ThreadPool.h:279: DB::CompletedPipelineExecutor::execute() @ 0x00000000169af267 5. /build/src/Server/TCPHandler.cpp:707: DB::TCPHandler::runImpl() @ 0x00000000168e6b2e 6. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 7. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 8. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 9. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 10. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 11. ? @ 0x00007fbc6213eac3 12. ? @ 0x00007fbc621d0850 2025.07.28 11:50:47.010839 [ 10323 ] {9d0d6ab2-d8bd-42d3-bf20-07ca65ff1f48} executeQuery: Code: 36. DB::Exception: Point (1.8446744073709552e+19, 1.8446744073709552e+19) is invalid in function geoToS2. For valid point the latitude is between -90 and 90 degrees inclusiveand the longitude is between -180 and 180 degrees inclusive.: In scope SELECT geoToS2(toFloat64(toUInt64(-1)), toFloat64(toUInt64(-1))). (BAD_ARGUMENTS) (version 25.3.6.10636.altinitytest (altinity build)) (from [::1]:59882) (comment: 02816_s2_invalid_point.sql) (query 1, line 3) (in query: SELECT geoToS2(toFloat64(toUInt64(-1)), toFloat64(toUInt64(-1)));), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, double const&, double const&, String&&) @ 0x000000000ba5862b 4. /build/src/Functions/geoToS2.cpp:131: DB::(anonymous namespace)::FunctionGeoToS2::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000ba580a5 5. /build/src/Functions/IFunction.h:437: DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000a069f2a 6. /build/src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000012d9965a 7. /build/src/Functions/IFunction.cpp:351: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d93b02 8. /build/src/Functions/IFunction.cpp:177: DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d93698 9. /build/src/Functions/IFunction.cpp:343: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d93aad 10. /build/src/Functions/IFunction.cpp:420: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d95059 11. /build/src/Functions/IFunction.cpp:498: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d95c72 12. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3567: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000014034494 13. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3838: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000014019a9e 14. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3980: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000014018e31 15. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:4304: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000014042fa7 16. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5605: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000014013749 17. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000140127f9 18. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000014011fce 19. /build/src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000001406ce8a 20. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000014973b42 21. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000001497268d 22. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000014974d24 23. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001492924b 24. /build/src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88641 25. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 26. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 27. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 28. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 29. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 30. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 31. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 2025.07.28 11:50:47.026793 [ 10323 ] {} TCPHandler: Code: 36. DB::Exception: Point (1.8446744073709552e+19, 1.8446744073709552e+19) is invalid in function geoToS2. For valid point the latitude is between -90 and 90 degrees inclusiveand the longitude is between -180 and 180 degrees inclusive.: In scope SELECT geoToS2(toFloat64(toUInt64(-1)), toFloat64(toUInt64(-1))). (BAD_ARGUMENTS), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, double const&, double const&, String&&) @ 0x000000000ba5862b 4. /build/src/Functions/geoToS2.cpp:131: DB::(anonymous namespace)::FunctionGeoToS2::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000ba580a5 5. /build/src/Functions/IFunction.h:437: DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000a069f2a 6. /build/src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000012d9965a 7. /build/src/Functions/IFunction.cpp:351: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d93b02 8. /build/src/Functions/IFunction.cpp:177: DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d93698 9. /build/src/Functions/IFunction.cpp:343: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d93aad 10. /build/src/Functions/IFunction.cpp:420: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d95059 11. /build/src/Functions/IFunction.cpp:498: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d95c72 12. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3567: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000014034494 13. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3838: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000014019a9e 14. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3980: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000014018e31 15. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:4304: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000014042fa7 16. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5605: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000014013749 17. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000140127f9 18. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000014011fce 19. /build/src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000001406ce8a 20. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000014973b42 21. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000001497268d 22. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000014974d24 23. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001492924b 24. /build/src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88641 25. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 26. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 27. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 28. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 29. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 30. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 31. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 2025.07.28 11:50:48.849137 [ 11851 ] {a0f25496-769e-4e8e-b5da-a971e342458d} executeQuery: Code: 47. DB::Exception: Unknown expression or function identifier `x` in scope x = 1. (UNKNOWN_IDENTIFIER) (version 25.3.6.10636.altinitytest (altinity build)) (from [::1]:59964) (comment: 03098_prefer_column_to_alias_subquery.sql) (query 8, line 24) (in query: -- This query returns the expected result -- 300 \N 3 -- 200 \N 2 -- 100 \N 1 -- \N 30 3 -- \N 20 2 -- \N 10 1 SELECT * FROM ( SELECT max(`column_1`) AS `column_1`, NULL AS `column_2`, `id` FROM `clickhouse_alias_issue_1` GROUP BY `id` UNION ALL SELECT NULL AS `column_1`, max(`column_2`) AS `column_2`, `id` FROM `clickhouse_alias_issue_2` GROUP BY `id` SETTINGS prefer_column_name_to_alias=1 ) ORDER BY ALL DESC NULLS LAST;), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.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&&) @ 0x000000001404b3b9 4. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3771: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000001401b849 5. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3980: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000014018e31 6. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:2925: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000001402fcbd 7. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3838: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000014019a9e 8. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:209: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000001401270e 9. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000014011fce 10. /build/src/Planner/Utils.cpp:458: DB::buildFilterInfo(std::shared_ptr, std::shared_ptr const&, std::shared_ptr&, std::unordered_set, std::equal_to, std::allocator>) @ 0x0000000013fe8bcf 11. /build/src/Planner/PlannerJoinTree.cpp:535: DB::(anonymous namespace)::buildQueryPlanForTableExpression(std::shared_ptr, std::shared_ptr const&, DB::SelectQueryInfo const&, DB::SelectQueryOptions const&, std::shared_ptr&, bool, bool) @ 0x00000000149956d3 12. /build/src/Planner/PlannerJoinTree.cpp:2252: DB::buildJoinTreeQueryPlan(std::shared_ptr const&, DB::SelectQueryInfo const&, DB::SelectQueryOptions&, std::unordered_set, std::equal_to, std::allocator> const&, std::shared_ptr&) @ 0x000000001498e109 13. /build/src/Planner/Planner.cpp:1553: DB::Planner::buildPlanForQueryNode() @ 0x0000000014979dae 14. /build/src/Planner/Planner.cpp:1308: DB::Planner::buildQueryPlanIfNeeded() @ 0x000000001497685c 15. /build/src/Planner/Planner.cpp:1348: DB::Planner::buildPlanForUnionNode() @ 0x0000000014976e4c 16. /build/src/Planner/Planner.cpp:1306: DB::Planner::buildQueryPlanIfNeeded() @ 0x0000000014976855 17. /build/src/Planner/PlannerJoinTree.cpp:1202: DB::(anonymous namespace)::buildQueryPlanForTableExpression(std::shared_ptr, std::shared_ptr const&, DB::SelectQueryInfo const&, DB::SelectQueryOptions const&, std::shared_ptr&, bool, bool) @ 0x0000000014994644 18. /build/src/Planner/PlannerJoinTree.cpp:2252: DB::buildJoinTreeQueryPlan(std::shared_ptr const&, DB::SelectQueryInfo const&, DB::SelectQueryOptions&, std::unordered_set, std::equal_to, std::allocator> const&, std::shared_ptr&) @ 0x000000001498e109 19. /build/src/Planner/Planner.cpp:1553: DB::Planner::buildPlanForQueryNode() @ 0x0000000014979dae 20. /build/src/Planner/Planner.cpp:1308: DB::Planner::buildQueryPlanIfNeeded() @ 0x000000001497685c 21. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:255: DB::InterpreterSelectQueryAnalyzer::getQueryPlan() @ 0x000000001497476d 22. /build/src/Interpreters/executeQuery.cpp:1405: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88806 23. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 24. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 25. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 26. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 27. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 28. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 29. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 30. ? @ 0x00007fbc6213eac3 31. ? @ 0x00007fbc621d0850 2025.07.28 11:50:48.881236 [ 11851 ] {} TCPHandler: Code: 47. DB::Exception: Unknown expression or function identifier `x` in scope x = 1. (UNKNOWN_IDENTIFIER), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.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&&) @ 0x000000001404b3b9 4. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3771: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000001401b849 5. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3980: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000014018e31 6. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:2925: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000001402fcbd 7. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3838: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000014019a9e 8. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:209: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000001401270e 9. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000014011fce 10. /build/src/Planner/Utils.cpp:458: DB::buildFilterInfo(std::shared_ptr, std::shared_ptr const&, std::shared_ptr&, std::unordered_set, std::equal_to, std::allocator>) @ 0x0000000013fe8bcf 11. /build/src/Planner/PlannerJoinTree.cpp:535: DB::(anonymous namespace)::buildQueryPlanForTableExpression(std::shared_ptr, std::shared_ptr const&, DB::SelectQueryInfo const&, DB::SelectQueryOptions const&, std::shared_ptr&, bool, bool) @ 0x00000000149956d3 12. /build/src/Planner/PlannerJoinTree.cpp:2252: DB::buildJoinTreeQueryPlan(std::shared_ptr const&, DB::SelectQueryInfo const&, DB::SelectQueryOptions&, std::unordered_set, std::equal_to, std::allocator> const&, std::shared_ptr&) @ 0x000000001498e109 13. /build/src/Planner/Planner.cpp:1553: DB::Planner::buildPlanForQueryNode() @ 0x0000000014979dae 14. /build/src/Planner/Planner.cpp:1308: DB::Planner::buildQueryPlanIfNeeded() @ 0x000000001497685c 15. /build/src/Planner/Planner.cpp:1348: DB::Planner::buildPlanForUnionNode() @ 0x0000000014976e4c 16. /build/src/Planner/Planner.cpp:1306: DB::Planner::buildQueryPlanIfNeeded() @ 0x0000000014976855 17. /build/src/Planner/PlannerJoinTree.cpp:1202: DB::(anonymous namespace)::buildQueryPlanForTableExpression(std::shared_ptr, std::shared_ptr const&, DB::SelectQueryInfo const&, DB::SelectQueryOptions const&, std::shared_ptr&, bool, bool) @ 0x0000000014994644 18. /build/src/Planner/PlannerJoinTree.cpp:2252: DB::buildJoinTreeQueryPlan(std::shared_ptr const&, DB::SelectQueryInfo const&, DB::SelectQueryOptions&, std::unordered_set, std::equal_to, std::allocator> const&, std::shared_ptr&) @ 0x000000001498e109 19. /build/src/Planner/Planner.cpp:1553: DB::Planner::buildPlanForQueryNode() @ 0x0000000014979dae 20. /build/src/Planner/Planner.cpp:1308: DB::Planner::buildQueryPlanIfNeeded() @ 0x000000001497685c 21. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:255: DB::InterpreterSelectQueryAnalyzer::getQueryPlan() @ 0x000000001497476d 22. /build/src/Interpreters/executeQuery.cpp:1405: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88806 23. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 24. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 25. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 26. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 27. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 28. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 29. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 30. ? @ 0x00007fbc6213eac3 31. ? @ 0x00007fbc621d0850 2025.07.28 11:50:49.348415 [ 4454 ] {} 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. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x000000000c25bc4b 4. /build/src/Access/SettingsConstraints.cpp:343: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000138596e3 5. /build/src/Access/SettingsConstraints.cpp:300: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000013858faf 6. /build/src/Access/SettingsConstraints.cpp:209: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x00000000138592b8 7. /build/src/Interpreters/Context.cpp:2690: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000014436134 8. /build/src/Interpreters/Context.cpp:2729: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x000000001443662b 9. /build/src/Server/TCPHandler.cpp:2158: DB::TCPHandler::processQuery(std::optional&) @ 0x00000000168f61df 10. /build/src/Server/TCPHandler.cpp:918: DB::TCPHandler::receivePacketsExpectQuery(std::optional&) @ 0x00000000168ef965 11. /build/src/Server/TCPHandler.cpp:491: DB::TCPHandler::runImpl() @ 0x00000000168e5eb4 12. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 13. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 14. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 16. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 17. ? @ 0x00007fbc6213eac3 18. ? @ 0x00007fbc621d0850 2025.07.28 11:50:49.421005 [ 4454 ] {} 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. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000000a074fcb 4. /build/src/Server/TCPHandler.cpp:897: DB::TCPHandler::receivePacketsExpectQuery(std::optional&) @ 0x00000000168efa89 5. /build/src/Server/TCPHandler.cpp:491: DB::TCPHandler::runImpl() @ 0x00000000168e5eb4 6. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 7. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 8. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 9. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 10. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 11. ? @ 0x00007fbc6213eac3 12. ? @ 0x00007fbc621d0850 2025.07.28 11:50:51.084803 [ 4454 ] {} 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. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x000000000c25bc4b 4. /build/src/Access/SettingsConstraints.cpp:343: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000138596e3 5. /build/src/Access/SettingsConstraints.cpp:300: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000013858faf 6. /build/src/Access/SettingsConstraints.cpp:209: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x00000000138592b8 7. /build/src/Interpreters/Context.cpp:2690: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000014436134 8. /build/src/Interpreters/Context.cpp:2729: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x000000001443662b 9. /build/src/Server/TCPHandler.cpp:2158: DB::TCPHandler::processQuery(std::optional&) @ 0x00000000168f61df 10. /build/src/Server/TCPHandler.cpp:918: DB::TCPHandler::receivePacketsExpectQuery(std::optional&) @ 0x00000000168ef965 11. /build/src/Server/TCPHandler.cpp:491: DB::TCPHandler::runImpl() @ 0x00000000168e5eb4 12. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 13. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 14. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 16. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 17. ? @ 0x00007fbc6213eac3 18. ? @ 0x00007fbc621d0850 2025.07.28 11:50:51.087088 [ 4454 ] {} 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. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000000a074fcb 4. /build/src/Server/TCPHandler.cpp:897: DB::TCPHandler::receivePacketsExpectQuery(std::optional&) @ 0x00000000168efa89 5. /build/src/Server/TCPHandler.cpp:491: DB::TCPHandler::runImpl() @ 0x00000000168e5eb4 6. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 7. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 8. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 9. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 10. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 11. ? @ 0x00007fbc6213eac3 12. ? @ 0x00007fbc621d0850 2025.07.28 11:50:51.358287 [ 12802 ] {} 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. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception>&, String>(int, FormatStringHelperImpl>&>::type, std::type_identity::type>, std::basic_string_view>&, String&&) @ 0x000000001385a5eb 4. /build/src/Access/SettingsConstraints.cpp:376: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000013859b18 5. /build/src/Access/SettingsConstraints.cpp:300: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000013858faf 6. /build/src/Access/SettingsConstraints.cpp:209: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000013859223 7. /build/src/Interpreters/Context.cpp:2690: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000014436134 8. /build/src/Interpreters/Context.cpp:2729: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x000000001443662b 9. /build/src/Server/HTTPHandler.cpp:457: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000001686d165 10. /build/src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x0000000016870807 11. /build/src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x0000000016907e99 12. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 13. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 14. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 15. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 16. ? @ 0x00007fbc6213eac3 17. ? @ 0x00007fbc621d0850 (version 25.3.6.10636.altinitytest (altinity build)) 2025.07.28 11:50:51.544554 [ 12754 ] {8ae4cb98-0f8f-4aff-b2d7-18fd65b7db39} executeQuery: Code: 36. DB::Exception: Path of the custom local disk must be inside `/var/lib/clickhouse/disks/` directory: While processing disk(type = local, path = '/local/'). (BAD_ARGUMENTS) (version 25.3.6.10636.altinitytest (altinity build)) (from 0.0.0.0:0) (comment: 02454_create_table_with_custom_disk.sh) (in query: /* ddl_entry=query-0000000002 */ CREATE TABLE test_0sa8zp0e.test UUID 'caa563e5-be56-4832-9a1e-943ced6526a8' (`a` Int32) ENGINE = MergeTree ORDER BY tuple() SETTINGS disk = disk(type = local, path = '/local/')), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x000000000a080b2b 4. /build/src/Disks/DiskFromAST.cpp:88: DB::getOrCreateCustomDisk(Poco::AutoPtr, String const&, std::shared_ptr, bool) @ 0x000000001650c9ed 5. /build/src/Disks/DiskFromAST.cpp:117: DB::DiskConfigurationFlattener::visit(std::shared_ptr&, DB::DiskConfigurationFlattener::Data&) @ 0x000000001650d55c 6. /build/src/Interpreters/InDepthNodeVisitor.h:71: DB::InDepthNodeVisitor>::doVisit(std::shared_ptr&) @ 0x000000001650d3d5 7. /build/src/Interpreters/InDepthNodeVisitor.h:61: DB::DiskFromAST::createCustomDisk(std::shared_ptr const&, std::shared_ptr, bool) @ 0x000000001650ccea 8. /build/src/Storages/MergeTree/MergeTreeSettings.cpp:398: DB::MergeTreeSettingsImpl::loadFromQuery(DB::ASTStorage&, std::shared_ptr, bool) @ 0x00000000164df189 9. /build/src/Storages/MergeTree/MergeTreeSettings.cpp:714: DB::MergeTreeSettings::loadFromQuery(DB::ASTStorage&, std::shared_ptr, bool) @ 0x00000000164e1a24 10. /build/src/Storages/MergeTree/registerStorageMergeTree.cpp:705: DB::create(DB::StorageFactory::Arguments const&) @ 0x000000001662dffe 11. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000015d81ea2 12. /build/src/Interpreters/InterpreterCreateQuery.cpp:1945: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x00000000149009bb 13. /build/src/Interpreters/InterpreterCreateQuery.cpp:1743: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000148f9aa9 14. /build/src/Interpreters/InterpreterCreateQuery.cpp:2352: DB::InterpreterCreateQuery::execute() @ 0x0000000014905a41 15. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88dc9 16. /build/src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x0000000014c8ca7b 17. /build/src/Interpreters/DDLWorker.cpp:510: DB::DDLWorker::tryExecuteQuery(DB::DDLTaskBase&, std::shared_ptr const&, bool) @ 0x00000000144dab9e 18. /build/src/Interpreters/DDLWorker.cpp:675: DB::DDLWorker::processTask(DB::DDLTaskBase&, std::shared_ptr const&, bool) @ 0x00000000144d8ffe 19. /build/src/Databases/DatabaseReplicatedWorker.cpp:372: DB::DatabaseReplicatedDDLWorker::tryEnqueueAndExecuteEntry(DB::DDLLogEntry&, std::shared_ptr, bool) @ 0x0000000013dc29ab 20. /build/src/Databases/DatabaseReplicated.cpp:1139: DB::DatabaseReplicated::tryEnqueueReplicatedDDL(std::shared_ptr const&, std::shared_ptr, DB::QueryFlags) @ 0x0000000013d9f73c 21. /build/src/Interpreters/InterpreterCreateQuery.cpp:1723: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000148f96f8 22. /build/src/Interpreters/InterpreterCreateQuery.cpp:2352: DB::InterpreterCreateQuery::execute() @ 0x0000000014905a41 23. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88dc9 24. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 25. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 26. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 27. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 28. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 29. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 30. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 31. ? @ 0x00007fbc6213eac3 2025.07.28 11:50:51.577097 [ 12754 ] {8ae4cb98-0f8f-4aff-b2d7-18fd65b7db39} executeQuery: Code: 36. DB::Exception: Path of the custom local disk must be inside `/var/lib/clickhouse/disks/` directory: While processing disk(type = local, path = '/local/'). (BAD_ARGUMENTS) (version 25.3.6.10636.altinitytest (altinity build)) (from [::1]:60310) (comment: 02454_create_table_with_custom_disk.sh) (query 3, line 9) (in query: CREATE TABLE test (a Int32) ENGINE = MergeTree() order by tuple() SETTINGS disk = disk(type=local, path='/local/');), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x000000000a080b2b 4. /build/src/Disks/DiskFromAST.cpp:88: DB::getOrCreateCustomDisk(Poco::AutoPtr, String const&, std::shared_ptr, bool) @ 0x000000001650c9ed 5. /build/src/Disks/DiskFromAST.cpp:117: DB::DiskConfigurationFlattener::visit(std::shared_ptr&, DB::DiskConfigurationFlattener::Data&) @ 0x000000001650d55c 6. /build/src/Interpreters/InDepthNodeVisitor.h:71: DB::InDepthNodeVisitor>::doVisit(std::shared_ptr&) @ 0x000000001650d3d5 7. /build/src/Interpreters/InDepthNodeVisitor.h:61: DB::DiskFromAST::createCustomDisk(std::shared_ptr const&, std::shared_ptr, bool) @ 0x000000001650ccea 8. /build/src/Storages/MergeTree/MergeTreeSettings.cpp:398: DB::MergeTreeSettingsImpl::loadFromQuery(DB::ASTStorage&, std::shared_ptr, bool) @ 0x00000000164df189 9. /build/src/Storages/MergeTree/MergeTreeSettings.cpp:714: DB::MergeTreeSettings::loadFromQuery(DB::ASTStorage&, std::shared_ptr, bool) @ 0x00000000164e1a24 10. /build/src/Storages/MergeTree/registerStorageMergeTree.cpp:705: DB::create(DB::StorageFactory::Arguments const&) @ 0x000000001662dffe 11. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000015d81ea2 12. /build/src/Interpreters/InterpreterCreateQuery.cpp:1945: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x00000000149009bb 13. /build/src/Interpreters/InterpreterCreateQuery.cpp:1743: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000148f9aa9 14. /build/src/Interpreters/InterpreterCreateQuery.cpp:2352: DB::InterpreterCreateQuery::execute() @ 0x0000000014905a41 15. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88dc9 16. /build/src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x0000000014c8ca7b 17. /build/src/Interpreters/DDLWorker.cpp:510: DB::DDLWorker::tryExecuteQuery(DB::DDLTaskBase&, std::shared_ptr const&, bool) @ 0x00000000144dab9e 18. /build/src/Interpreters/DDLWorker.cpp:675: DB::DDLWorker::processTask(DB::DDLTaskBase&, std::shared_ptr const&, bool) @ 0x00000000144d8ffe 19. /build/src/Databases/DatabaseReplicatedWorker.cpp:372: DB::DatabaseReplicatedDDLWorker::tryEnqueueAndExecuteEntry(DB::DDLLogEntry&, std::shared_ptr, bool) @ 0x0000000013dc29ab 20. /build/src/Databases/DatabaseReplicated.cpp:1139: DB::DatabaseReplicated::tryEnqueueReplicatedDDL(std::shared_ptr const&, std::shared_ptr, DB::QueryFlags) @ 0x0000000013d9f73c 21. /build/src/Interpreters/InterpreterCreateQuery.cpp:1723: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000148f96f8 22. /build/src/Interpreters/InterpreterCreateQuery.cpp:2352: DB::InterpreterCreateQuery::execute() @ 0x0000000014905a41 23. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88dc9 24. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 25. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 26. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 27. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 28. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 29. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 30. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 31. ? @ 0x00007fbc6213eac3 2025.07.28 11:50:51.579273 [ 12115 ] {83818bc4-f7ff-481f-9e79-748329eda8d4} executeQuery: Code: 48. DB::Exception: Only `hash` join supports multiple ORs for keys in JOIN ON section. (NOT_IMPLEMENTED) (version 25.3.6.10636.altinitytest (altinity build)) (from [::1]:57736) (comment: 01661_join_complex.sql) (query 1, line 1) (in query: select * from (select 'a' as a, 'b' as b, 'c' as c, 'd' as d, 'e' as e, 'f' as f) as t1 inner join (select 'a' as a, 'b' as b, 'c' as c, 'd' as d, 'e' as e, 'f' as f) as t2 on t1.b = t2.b and t1.c = t2.b and t1.d = t2.b or t1.e = t2.e;), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000000a074fcb 4. /build/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) @ 0x00000000149c5d03 5. /build/src/Planner/PlannerJoinTree.cpp:1428: 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&) @ 0x00000000149a05d7 6. /build/src/Planner/PlannerJoinTree.cpp:1967: DB::(anonymous namespace)::buildQueryPlanForJoinNodeLegacy(std::shared_ptr const&, DB::JoinTreeQueryPlan, DB::JoinTreeQueryPlan, std::unordered_set, std::equal_to, std::allocator> const&, std::shared_ptr&, DB::SelectQueryInfo const&) @ 0x000000001499e4a4 7. /build/src/Planner/PlannerJoinTree.cpp:2058: DB::buildJoinTreeQueryPlan(std::shared_ptr const&, DB::SelectQueryInfo const&, DB::SelectQueryOptions&, std::unordered_set, std::equal_to, std::allocator> const&, std::shared_ptr&) @ 0x000000001498eccc 8. /build/src/Planner/Planner.cpp:1553: DB::Planner::buildPlanForQueryNode() @ 0x0000000014979dae 9. /build/src/Planner/Planner.cpp:1308: DB::Planner::buildQueryPlanIfNeeded() @ 0x000000001497685c 10. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:255: DB::InterpreterSelectQueryAnalyzer::getQueryPlan() @ 0x000000001497476d 11. /build/src/Interpreters/executeQuery.cpp:1405: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88806 12. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 13. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 14. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 15. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 16. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 17. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 18. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 19. ? @ 0x00007fbc6213eac3 20. ? @ 0x00007fbc621d0850 2025.07.28 11:50:51.580709 [ 12754 ] {} TCPHandler: Code: 36. DB::Exception: Path of the custom local disk must be inside `/var/lib/clickhouse/disks/` directory: While processing disk(type = local, path = '/local/'). (BAD_ARGUMENTS), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x000000000a080b2b 4. /build/src/Disks/DiskFromAST.cpp:88: DB::getOrCreateCustomDisk(Poco::AutoPtr, String const&, std::shared_ptr, bool) @ 0x000000001650c9ed 5. /build/src/Disks/DiskFromAST.cpp:117: DB::DiskConfigurationFlattener::visit(std::shared_ptr&, DB::DiskConfigurationFlattener::Data&) @ 0x000000001650d55c 6. /build/src/Interpreters/InDepthNodeVisitor.h:71: DB::InDepthNodeVisitor>::doVisit(std::shared_ptr&) @ 0x000000001650d3d5 7. /build/src/Interpreters/InDepthNodeVisitor.h:61: DB::DiskFromAST::createCustomDisk(std::shared_ptr const&, std::shared_ptr, bool) @ 0x000000001650ccea 8. /build/src/Storages/MergeTree/MergeTreeSettings.cpp:398: DB::MergeTreeSettingsImpl::loadFromQuery(DB::ASTStorage&, std::shared_ptr, bool) @ 0x00000000164df189 9. /build/src/Storages/MergeTree/MergeTreeSettings.cpp:714: DB::MergeTreeSettings::loadFromQuery(DB::ASTStorage&, std::shared_ptr, bool) @ 0x00000000164e1a24 10. /build/src/Storages/MergeTree/registerStorageMergeTree.cpp:705: DB::create(DB::StorageFactory::Arguments const&) @ 0x000000001662dffe 11. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000015d81ea2 12. /build/src/Interpreters/InterpreterCreateQuery.cpp:1945: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x00000000149009bb 13. /build/src/Interpreters/InterpreterCreateQuery.cpp:1743: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000148f9aa9 14. /build/src/Interpreters/InterpreterCreateQuery.cpp:2352: DB::InterpreterCreateQuery::execute() @ 0x0000000014905a41 15. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88dc9 16. /build/src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x0000000014c8ca7b 17. /build/src/Interpreters/DDLWorker.cpp:510: DB::DDLWorker::tryExecuteQuery(DB::DDLTaskBase&, std::shared_ptr const&, bool) @ 0x00000000144dab9e 18. /build/src/Interpreters/DDLWorker.cpp:675: DB::DDLWorker::processTask(DB::DDLTaskBase&, std::shared_ptr const&, bool) @ 0x00000000144d8ffe 19. /build/src/Databases/DatabaseReplicatedWorker.cpp:372: DB::DatabaseReplicatedDDLWorker::tryEnqueueAndExecuteEntry(DB::DDLLogEntry&, std::shared_ptr, bool) @ 0x0000000013dc29ab 20. /build/src/Databases/DatabaseReplicated.cpp:1139: DB::DatabaseReplicated::tryEnqueueReplicatedDDL(std::shared_ptr const&, std::shared_ptr, DB::QueryFlags) @ 0x0000000013d9f73c 21. /build/src/Interpreters/InterpreterCreateQuery.cpp:1723: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000148f96f8 22. /build/src/Interpreters/InterpreterCreateQuery.cpp:2352: DB::InterpreterCreateQuery::execute() @ 0x0000000014905a41 23. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88dc9 24. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 25. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 26. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 27. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 28. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 29. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 30. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 31. ? @ 0x00007fbc6213eac3 2025.07.28 11:50:51.604143 [ 12115 ] {} 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. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000000a074fcb 4. /build/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) @ 0x00000000149c5d03 5. /build/src/Planner/PlannerJoinTree.cpp:1428: 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&) @ 0x00000000149a05d7 6. /build/src/Planner/PlannerJoinTree.cpp:1967: DB::(anonymous namespace)::buildQueryPlanForJoinNodeLegacy(std::shared_ptr const&, DB::JoinTreeQueryPlan, DB::JoinTreeQueryPlan, std::unordered_set, std::equal_to, std::allocator> const&, std::shared_ptr&, DB::SelectQueryInfo const&) @ 0x000000001499e4a4 7. /build/src/Planner/PlannerJoinTree.cpp:2058: DB::buildJoinTreeQueryPlan(std::shared_ptr const&, DB::SelectQueryInfo const&, DB::SelectQueryOptions&, std::unordered_set, std::equal_to, std::allocator> const&, std::shared_ptr&) @ 0x000000001498eccc 8. /build/src/Planner/Planner.cpp:1553: DB::Planner::buildPlanForQueryNode() @ 0x0000000014979dae 9. /build/src/Planner/Planner.cpp:1308: DB::Planner::buildQueryPlanIfNeeded() @ 0x000000001497685c 10. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:255: DB::InterpreterSelectQueryAnalyzer::getQueryPlan() @ 0x000000001497476d 11. /build/src/Interpreters/executeQuery.cpp:1405: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88806 12. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 13. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 14. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 15. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 16. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 17. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 18. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 19. ? @ 0x00007fbc6213eac3 20. ? @ 0x00007fbc621d0850 2025.07.28 11:50:51.979356 [ 12802 ] {e8696f03-f195-4bf6-9f98-2a995811a589} executeQuery: Code: 57. DB::Exception: Table test_1.test already exists. (TABLE_ALREADY_EXISTS) (version 25.3.6.10636.altinitytest (altinity build)) (from [::1]:57754) (comment: 03299_deep_nested_map_creation.sql) (query 1, line 1) (in query: CREATE TABLE test (`x` Map(Map(Map(Map(Map(Map(Map(Map(Map(Map(Map(Map(Map(Map(Map(Map(Map(Map(Map(Map(Map(Map(Map(Map(Map(Map(Map(Map(Map(Map(Map(Map(Map(Map(Map(Map(Map(Map(Map(Map(Map(Map(Map(Map(Map(Map(Map(Map(Map(Map(Map(Map(Map(Map(Map(Map(Map(Map(Map(Map(Map(Map(Map(Map(Map(Map(Map(Map(Map(Map(Map(Map(Map(Map(Map(Map(Map(Map(Map(Map(Map(Map(Map(Map(Map(Map(Map(Map(Map(Map(Map(Map(Map(Map(Map(Map(Map(Map(Map(Map(Int32, Int32), Int32), Int32), Int32), Int32), Int32), Int32), Int32), Int32), Int32), Int32), Int32), Int32), Int32), Int32), Int32), Int32), Int32), Int32), Int32), Int32), Int32), Int32), Int32), Int32), Int32), Int32), Int32), Int32), Int32), Int32), Int32), Int32), Int32), Int32), Int32), Int32), Int32), Int32), Int32), Int32), Int32), Int32), Int32), Int32), Int32), Int32), Int32), Int32), Int32), Int32), Int32), Int32), Int32), Int32), Int32), Int32), Int32), Int32), Int32), Int32), Int32), Int32), Int32), Int32), Int32), Int32), Int32), Int32), Int32), Int32), Int32), Int32), Int32), Int32), Int32), Int32), Int32), Int32), Int32), Int32), Int32), Int32), Int32), Int32), Int32), Int32), Int32), Int32), Int32), Int32), Int32), Int32), Int32), Int32), Int32), Int32), Int32), Int32), Int32)) ENGINE = MergeTree ORDER BY tuple() SETTINGS index_granularity = 3040, min_bytes_for_wide_part = 0, ratio_of_defaults_for_sparse_serialization = 1., replace_long_file_name_to_hash = false, max_file_name_length = 44, min_bytes_for_full_part_storage = 54586520, compact_parts_max_bytes_to_buffer = 219567344, compact_parts_max_granules_to_buffer = 177, compact_parts_merge_max_bytes_to_prefetch_part = 15724547, merge_max_block_size = 4909, old_parts_lifetime = 267., prefer_fetch_merged_part_size_threshold = 10737418240, vertical_merge_algorithm_min_rows_to_activate = 16923, vertical_merge_algorithm_min_columns_to_activate = 100, min_merge_bytes_to_use_direct_io = 6400481109, index_granularity_bytes = 24209433, 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 = true, cache_populated_by_fetch = true, marks_compress_block_size = 33915, primary_key_compress_block_size = 86954, 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. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000a06a8eb 4. /build/src/Interpreters/InterpreterCreateQuery.cpp:1824: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x0000000014901d53 5. /build/src/Interpreters/InterpreterCreateQuery.cpp:1743: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000148f9aa9 6. /build/src/Interpreters/InterpreterCreateQuery.cpp:2352: DB::InterpreterCreateQuery::execute() @ 0x0000000014905a41 7. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88dc9 8. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 9. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 10. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 11. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 12. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 13. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 14. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 15. ? @ 0x00007fbc6213eac3 16. ? @ 0x00007fbc621d0850 2025.07.28 11:50:52.026854 [ 12802 ] {} 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. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000a06a8eb 4. /build/src/Interpreters/InterpreterCreateQuery.cpp:1824: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x0000000014901d53 5. /build/src/Interpreters/InterpreterCreateQuery.cpp:1743: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000148f9aa9 6. /build/src/Interpreters/InterpreterCreateQuery.cpp:2352: DB::InterpreterCreateQuery::execute() @ 0x0000000014905a41 7. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88dc9 8. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 9. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 10. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 11. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 12. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 13. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 14. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 15. ? @ 0x00007fbc6213eac3 16. ? @ 0x00007fbc621d0850 2025.07.28 11:50:52.314115 [ 5951 ] {6107a5cc-72a7-4418-9b00-a2b760b557b1} executeQuery: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=818, jobs=783). (CANNOT_SCHEDULE_TASK) (version 25.3.6.10636.altinitytest (altinity build)) (from [::ffff:127.0.0.1]:42324) (comment: 03254_limit_by_with_offset_parallel_replicas.sh) (query 11, line 14) (in query: SELECT `__table1`.`a` AS `a` FROM `test_13`.`ties` AS `__table1` ORDER BY `__table1`.`a` ASC LIMIT _CAST(2, 'UInt64'), _CAST(3, 'UInt64') WITH TIES), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000fccaeeb 4. /build/src/Common/ThreadPool.cpp:275: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000fccacb3 5. /build/src/Common/ThreadPool.cpp:323: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fcc4ffc 6. /build/src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000000fcc584d 7. /build/src/Common/ThreadPool.h:279: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x00000000169bf193 8. /build/src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x00000000169bf518 9. /build/src/Server/TCPHandler.cpp:1237: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x00000000168f1525 10. /build/src/Server/TCPHandler.cpp:678: DB::TCPHandler::runImpl() @ 0x00000000168e68e5 11. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 12. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 13. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 14. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 15. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 16. ? @ 0x00007fbc6213eac3 17. ? @ 0x00007fbc621d0850 2025.07.28 11:50:52.320129 [ 5951 ] {} TCPHandler: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=818, jobs=783). (CANNOT_SCHEDULE_TASK), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000fccaeeb 4. /build/src/Common/ThreadPool.cpp:275: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000fccacb3 5. /build/src/Common/ThreadPool.cpp:323: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fcc4ffc 6. /build/src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000000fcc584d 7. /build/src/Common/ThreadPool.h:279: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x00000000169bf193 8. /build/src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x00000000169bf518 9. /build/src/Server/TCPHandler.cpp:1237: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x00000000168f1525 10. /build/src/Server/TCPHandler.cpp:678: DB::TCPHandler::runImpl() @ 0x00000000168e68e5 11. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 12. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 13. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 14. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 15. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 16. ? @ 0x00007fbc6213eac3 17. ? @ 0x00007fbc621d0850 2025.07.28 11:50:52.500984 [ 3287 ] {46bd74cb-5963-4b44-887d-bd6d41cd61ad} executeQuery: Code: 439. DB::Exception: Received from 127.0.0.6:9000. DB::Exception: Cannot schedule a task: fault injected (threads=818, jobs=783). Stack trace: 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000fccaeeb 4. /build/src/Common/ThreadPool.cpp:275: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000fccacb3 5. /build/src/Common/ThreadPool.cpp:323: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fcc4ffc 6. /build/src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000000fcc584d 7. /build/src/Common/ThreadPool.h:279: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x00000000169bf193 8. /build/src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x00000000169bf518 9. /build/src/Server/TCPHandler.cpp:1237: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x00000000168f1525 10. /build/src/Server/TCPHandler.cpp:678: DB::TCPHandler::runImpl() @ 0x00000000168e68e5 11. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 12. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 13. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 14. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 15. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 16. ? @ 0x00007fbc6213eac3 17. ? @ 0x00007fbc621d0850 : While executing Remote. (CANNOT_SCHEDULE_TASK) (version 25.3.6.10636.altinitytest (altinity build)) (from [::1]:59322) (comment: 03254_limit_by_with_offset_parallel_replicas.sh) (query 11, line 14) (in query: SELECT a FROM ties order by a limit 2, 3 with ties;), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:111: DB::readException(DB::ReadBuffer&, String const&, bool) @ 0x000000000fc6e157 3. /build/src/Client/Connection.cpp:1445: DB::Connection::receiveException() const @ 0x00000000167d4127 4. /build/src/Client/Connection.cpp:1274: DB::Connection::receivePacket() @ 0x00000000167db312 5. /build/src/Client/MultiplexedConnections.cpp:380: DB::MultiplexedConnections::receivePacketUnlocked(std::function) @ 0x00000000168163a9 6. /build/src/QueryPipeline/RemoteQueryExecutorReadContext.cpp:67: DB::RemoteQueryExecutorReadContext::Task::run(std::function, std::function) @ 0x0000000013bd23fe 7. /build/src/Common/AsyncTaskExecutor.cpp:89: DB::AsyncTaskExecutor::Routine::operator()(std::function) @ 0x0000000013bd1892 8. /build/src/Common/Fiber.h:76: boost::context::detail::fiber_record>::run(void*) @ 0x0000000013bd16fa 9. /build/contrib/boost/boost/context/fiber_fcontext.hpp:97: void boost::context::detail::fiber_entry>>(boost::context::detail::transfer_t) @ 0x0000000013bd1621 2025.07.28 11:50:52.519955 [ 5112 ] {} TCPHandler: TCPHandler: Code: 210. DB::NetException: Connection reset by peer, while reading from socket (peer: [::ffff:127.0.0.1]:39948, local: [::ffff:127.0.0.9]:9000). (NETWORK_ERROR), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::NetException::NetException(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&) @ 0x000000000fd50fb5 3. /build/src/IO/ReadBufferFromPocoSocket.cpp:83: DB::ReadBufferFromPocoSocketBase::socketReceiveBytesImpl(char*, unsigned long) @ 0x000000000fd5052e 4. /build/src/IO/ReadBufferFromPocoSocket.cpp:107: DB::ReadBufferFromPocoSocketBase::nextImpl() @ 0x000000000fd50a63 5. /build/src/IO/ReadBuffer.h:60: DB::ReadBuffer::next() @ 0x000000000a148c7b 6. /build/src/IO/ReadBuffer.h:96: DB::TCPHandler::runImpl() @ 0x00000000168e5e5e 7. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 8. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 9. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 10. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 11. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 12. ? @ 0x00007fbc6213eac3 13. ? @ 0x00007fbc621d0850 (version 25.3.6.10636.altinitytest (altinity build)) 2025.07.28 11:50:52.520384 [ 7630 ] {} TCPHandler: TCPHandler: Code: 210. DB::NetException: Connection reset by peer, while reading from socket (peer: [::ffff:127.0.0.1]:38958, local: [::ffff:127.0.0.7]:9000). (NETWORK_ERROR), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::NetException::NetException(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&) @ 0x000000000fd50fb5 3. /build/src/IO/ReadBufferFromPocoSocket.cpp:83: DB::ReadBufferFromPocoSocketBase::socketReceiveBytesImpl(char*, unsigned long) @ 0x000000000fd5052e 4. /build/src/IO/ReadBufferFromPocoSocket.cpp:107: DB::ReadBufferFromPocoSocketBase::nextImpl() @ 0x000000000fd50a63 5. /build/src/IO/ReadBuffer.h:60: DB::ReadBuffer::next() @ 0x000000000a148c7b 6. /build/src/IO/ReadBuffer.h:96: DB::TCPHandler::runImpl() @ 0x00000000168e5e5e 7. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 8. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 9. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 10. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 11. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 12. ? @ 0x00007fbc6213eac3 13. ? @ 0x00007fbc621d0850 (version 25.3.6.10636.altinitytest (altinity build)) 2025.07.28 11:50:52.520595 [ 5112 ] {} ServerErrorHandler: Code: 210. DB::NetException: Connection reset by peer, while reading from socket (peer: [::ffff:127.0.0.1]:39948, local: [::ffff:127.0.0.9]:9000). (NETWORK_ERROR), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::NetException::NetException(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&) @ 0x000000000fd50fb5 3. /build/src/IO/ReadBufferFromPocoSocket.cpp:83: DB::ReadBufferFromPocoSocketBase::socketReceiveBytesImpl(char*, unsigned long) @ 0x000000000fd5052e 4. /build/src/IO/ReadBufferFromPocoSocket.cpp:107: DB::ReadBufferFromPocoSocketBase::nextImpl() @ 0x000000000fd50a63 5. /build/src/IO/ReadBuffer.h:60: DB::ReadBuffer::next() @ 0x000000000a148c7b 6. /build/src/IO/ReadBuffer.h:96: DB::TCPHandler::runImpl() @ 0x00000000168e5e5e 7. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 8. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 9. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 10. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 11. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 12. ? @ 0x00007fbc6213eac3 13. ? @ 0x00007fbc621d0850 (version 25.3.6.10636.altinitytest (altinity build)) 2025.07.28 11:50:52.521452 [ 3285 ] {} TCPHandler: TCPHandler: Code: 210. DB::NetException: Connection reset by peer, while reading from socket (peer: [::ffff:127.0.0.1]:38306, local: [::ffff:127.0.0.5]:9000). (NETWORK_ERROR), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::NetException::NetException(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&) @ 0x000000000fd50fb5 3. /build/src/IO/ReadBufferFromPocoSocket.cpp:83: DB::ReadBufferFromPocoSocketBase::socketReceiveBytesImpl(char*, unsigned long) @ 0x000000000fd5052e 4. /build/src/IO/ReadBufferFromPocoSocket.cpp:107: DB::ReadBufferFromPocoSocketBase::nextImpl() @ 0x000000000fd50a63 5. /build/src/IO/ReadBuffer.h:60: DB::ReadBuffer::next() @ 0x000000000a148c7b 6. /build/src/IO/ReadBuffer.h:96: DB::TCPHandler::runImpl() @ 0x00000000168e5e5e 7. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 8. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 9. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 10. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 11. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 12. ? @ 0x00007fbc6213eac3 13. ? @ 0x00007fbc621d0850 (version 25.3.6.10636.altinitytest (altinity build)) 2025.07.28 11:50:52.521504 [ 7630 ] {} ServerErrorHandler: Code: 210. DB::NetException: Connection reset by peer, while reading from socket (peer: [::ffff:127.0.0.1]:38958, local: [::ffff:127.0.0.7]:9000). (NETWORK_ERROR), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::NetException::NetException(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&) @ 0x000000000fd50fb5 3. /build/src/IO/ReadBufferFromPocoSocket.cpp:83: DB::ReadBufferFromPocoSocketBase::socketReceiveBytesImpl(char*, unsigned long) @ 0x000000000fd5052e 4. /build/src/IO/ReadBufferFromPocoSocket.cpp:107: DB::ReadBufferFromPocoSocketBase::nextImpl() @ 0x000000000fd50a63 5. /build/src/IO/ReadBuffer.h:60: DB::ReadBuffer::next() @ 0x000000000a148c7b 6. /build/src/IO/ReadBuffer.h:96: DB::TCPHandler::runImpl() @ 0x00000000168e5e5e 7. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 8. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 9. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 10. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 11. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 12. ? @ 0x00007fbc6213eac3 13. ? @ 0x00007fbc621d0850 (version 25.3.6.10636.altinitytest (altinity build)) 2025.07.28 11:50:52.522198 [ 3285 ] {} ServerErrorHandler: Code: 210. DB::NetException: Connection reset by peer, while reading from socket (peer: [::ffff:127.0.0.1]:38306, local: [::ffff:127.0.0.5]:9000). (NETWORK_ERROR), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::NetException::NetException(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&) @ 0x000000000fd50fb5 3. /build/src/IO/ReadBufferFromPocoSocket.cpp:83: DB::ReadBufferFromPocoSocketBase::socketReceiveBytesImpl(char*, unsigned long) @ 0x000000000fd5052e 4. /build/src/IO/ReadBufferFromPocoSocket.cpp:107: DB::ReadBufferFromPocoSocketBase::nextImpl() @ 0x000000000fd50a63 5. /build/src/IO/ReadBuffer.h:60: DB::ReadBuffer::next() @ 0x000000000a148c7b 6. /build/src/IO/ReadBuffer.h:96: DB::TCPHandler::runImpl() @ 0x00000000168e5e5e 7. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 8. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 9. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 10. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 11. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 12. ? @ 0x00007fbc6213eac3 13. ? @ 0x00007fbc621d0850 (version 25.3.6.10636.altinitytest (altinity build)) 2025.07.28 11:50:52.523964 [ 5327 ] {0cf5a7d9-8a6f-4818-8b82-baa38a9128df} executeQuery: Code: 210. DB::NetException: Connection reset by peer, while writing to socket ([::ffff:127.0.0.10]:9000 -> [::ffff:127.0.0.1]:37592). (NETWORK_ERROR) (version 25.3.6.10636.altinitytest (altinity build)) (from [::ffff:127.0.0.1]:37592) (comment: 03254_limit_by_with_offset_parallel_replicas.sh) (query 11, line 14) (in query: SELECT `__table1`.`a` AS `a` FROM `test_13`.`ties` AS `__table1` ORDER BY `__table1`.`a` ASC LIMIT _CAST(2, 'UInt64'), _CAST(3, 'UInt64') WITH TIES), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::NetException::NetException(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&) @ 0x000000000fd50fb5 3. /build/src/IO/WriteBufferFromPocoSocket.cpp:160: DB::WriteBufferFromPocoSocket::nextImpl() @ 0x000000000fd523f1 4. /build/src/IO/WriteBuffer.h:53: DB::WriteBuffer::next() @ 0x000000000a0755be 5. /build/src/Server/TCPHandler.cpp:2570: DB::TCPHandler::runImpl() @ 0x00000000168e6991 6. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 7. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 8. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 9. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 10. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 11. ? @ 0x00007fbc6213eac3 12. ? @ 0x00007fbc621d0850 2025.07.28 11:50:52.528011 [ 4508 ] {} TCPHandler: TCPHandler: Code: 210. DB::NetException: Connection reset by peer, while reading from socket (peer: [::ffff:127.0.0.1]:45356, local: [::ffff:127.0.0.8]:9000). (NETWORK_ERROR), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::NetException::NetException(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&) @ 0x000000000fd50fb5 3. /build/src/IO/ReadBufferFromPocoSocket.cpp:83: DB::ReadBufferFromPocoSocketBase::socketReceiveBytesImpl(char*, unsigned long) @ 0x000000000fd5052e 4. /build/src/IO/ReadBufferFromPocoSocket.cpp:107: DB::ReadBufferFromPocoSocketBase::nextImpl() @ 0x000000000fd50a63 5. /build/src/IO/ReadBuffer.h:60: DB::ReadBuffer::next() @ 0x000000000a148c7b 6. /build/src/IO/ReadBuffer.h:96: DB::TCPHandler::runImpl() @ 0x00000000168e5e5e 7. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 8. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 9. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 10. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 11. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 12. ? @ 0x00007fbc6213eac3 13. ? @ 0x00007fbc621d0850 (version 25.3.6.10636.altinitytest (altinity build)) 2025.07.28 11:50:52.528837 [ 4508 ] {} ServerErrorHandler: Code: 210. DB::NetException: Connection reset by peer, while reading from socket (peer: [::ffff:127.0.0.1]:45356, local: [::ffff:127.0.0.8]:9000). (NETWORK_ERROR), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::NetException::NetException(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&) @ 0x000000000fd50fb5 3. /build/src/IO/ReadBufferFromPocoSocket.cpp:83: DB::ReadBufferFromPocoSocketBase::socketReceiveBytesImpl(char*, unsigned long) @ 0x000000000fd5052e 4. /build/src/IO/ReadBufferFromPocoSocket.cpp:107: DB::ReadBufferFromPocoSocketBase::nextImpl() @ 0x000000000fd50a63 5. /build/src/IO/ReadBuffer.h:60: DB::ReadBuffer::next() @ 0x000000000a148c7b 6. /build/src/IO/ReadBuffer.h:96: DB::TCPHandler::runImpl() @ 0x00000000168e5e5e 7. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 8. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 9. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 10. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 11. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 12. ? @ 0x00007fbc6213eac3 13. ? @ 0x00007fbc621d0850 (version 25.3.6.10636.altinitytest (altinity build)) 2025.07.28 11:50:52.530544 [ 5327 ] {} TCPHandler: Code: 210. DB::NetException: Connection reset by peer, while writing to socket ([::ffff:127.0.0.10]:9000 -> [::ffff:127.0.0.1]:37592). (NETWORK_ERROR), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::NetException::NetException(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&) @ 0x000000000fd50fb5 3. /build/src/IO/WriteBufferFromPocoSocket.cpp:160: DB::WriteBufferFromPocoSocket::nextImpl() @ 0x000000000fd523f1 4. /build/src/IO/WriteBuffer.h:53: DB::WriteBuffer::next() @ 0x000000000a0755be 5. /build/src/Server/TCPHandler.cpp:2570: DB::TCPHandler::runImpl() @ 0x00000000168e6991 6. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 7. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 8. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 9. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 10. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 11. ? @ 0x00007fbc6213eac3 12. ? @ 0x00007fbc621d0850 2025.07.28 11:50:52.532988 [ 3287 ] {} TCPHandler: Code: 439. DB::Exception: Received from 127.0.0.6:9000. DB::Exception: Cannot schedule a task: fault injected (threads=818, jobs=783). Stack trace: 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000fccaeeb 4. /build/src/Common/ThreadPool.cpp:275: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000fccacb3 5. /build/src/Common/ThreadPool.cpp:323: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fcc4ffc 6. /build/src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000000fcc584d 7. /build/src/Common/ThreadPool.h:279: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x00000000169bf193 8. /build/src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x00000000169bf518 9. /build/src/Server/TCPHandler.cpp:1237: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x00000000168f1525 10. /build/src/Server/TCPHandler.cpp:678: DB::TCPHandler::runImpl() @ 0x00000000168e68e5 11. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 12. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 13. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 14. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 15. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 16. ? @ 0x00007fbc6213eac3 17. ? @ 0x00007fbc621d0850 : While executing Remote. (CANNOT_SCHEDULE_TASK), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:111: DB::readException(DB::ReadBuffer&, String const&, bool) @ 0x000000000fc6e157 3. /build/src/Client/Connection.cpp:1445: DB::Connection::receiveException() const @ 0x00000000167d4127 4. /build/src/Client/Connection.cpp:1274: DB::Connection::receivePacket() @ 0x00000000167db312 5. /build/src/Client/MultiplexedConnections.cpp:380: DB::MultiplexedConnections::receivePacketUnlocked(std::function) @ 0x00000000168163a9 6. /build/src/QueryPipeline/RemoteQueryExecutorReadContext.cpp:67: DB::RemoteQueryExecutorReadContext::Task::run(std::function, std::function) @ 0x0000000013bd23fe 7. /build/src/Common/AsyncTaskExecutor.cpp:89: DB::AsyncTaskExecutor::Routine::operator()(std::function) @ 0x0000000013bd1892 8. /build/src/Common/Fiber.h:76: boost::context::detail::fiber_record>::run(void*) @ 0x0000000013bd16fa 9. /build/contrib/boost/boost/context/fiber_fcontext.hpp:97: void boost::context::detail::fiber_entry>>(boost::context::detail::transfer_t) @ 0x0000000013bd1621 Job's origin stack trace: 0. /build/src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000000fc33b84 1. /build/src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000000fcc2ea7 2. /build/src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fcc535c 3. /build/src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000000fcc584d 4. /build/src/Common/ThreadPool.h:279: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x00000000169bf193 5. /build/src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x00000000169bf518 6. /build/src/Server/TCPHandler.cpp:1237: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x00000000168f1525 7. /build/src/Server/TCPHandler.cpp:678: DB::TCPHandler::runImpl() @ 0x00000000168e68e5 8. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 9. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 10. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 11. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 12. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 13. ? @ 0x00007fbc6213eac3 14. ? @ 0x00007fbc621d0850 2025.07.28 11:50:52.537633 [ 4446 ] {} TCPHandler: TCPHandler: Code: 210. DB::NetException: Connection reset by peer, while reading from socket (peer: [::ffff:127.0.0.1]:52220, local: [::ffff:127.0.0.3]:9000). (NETWORK_ERROR), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::NetException::NetException(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&) @ 0x000000000fd50fb5 3. /build/src/IO/ReadBufferFromPocoSocket.cpp:83: DB::ReadBufferFromPocoSocketBase::socketReceiveBytesImpl(char*, unsigned long) @ 0x000000000fd5052e 4. /build/src/IO/ReadBufferFromPocoSocket.cpp:107: DB::ReadBufferFromPocoSocketBase::nextImpl() @ 0x000000000fd50a63 5. /build/src/IO/ReadBuffer.h:60: DB::ReadBuffer::next() @ 0x000000000a148c7b 6. /build/src/IO/ReadBuffer.h:96: DB::TCPHandler::runImpl() @ 0x00000000168e5e5e 7. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 8. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 9. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 10. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 11. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 12. ? @ 0x00007fbc6213eac3 13. ? @ 0x00007fbc621d0850 (version 25.3.6.10636.altinitytest (altinity build)) 2025.07.28 11:50:52.538554 [ 4446 ] {} ServerErrorHandler: Code: 210. DB::NetException: Connection reset by peer, while reading from socket (peer: [::ffff:127.0.0.1]:52220, local: [::ffff:127.0.0.3]:9000). (NETWORK_ERROR), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::NetException::NetException(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&) @ 0x000000000fd50fb5 3. /build/src/IO/ReadBufferFromPocoSocket.cpp:83: DB::ReadBufferFromPocoSocketBase::socketReceiveBytesImpl(char*, unsigned long) @ 0x000000000fd5052e 4. /build/src/IO/ReadBufferFromPocoSocket.cpp:107: DB::ReadBufferFromPocoSocketBase::nextImpl() @ 0x000000000fd50a63 5. /build/src/IO/ReadBuffer.h:60: DB::ReadBuffer::next() @ 0x000000000a148c7b 6. /build/src/IO/ReadBuffer.h:96: DB::TCPHandler::runImpl() @ 0x00000000168e5e5e 7. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 8. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 9. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 10. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 11. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 12. ? @ 0x00007fbc6213eac3 13. ? @ 0x00007fbc621d0850 (version 25.3.6.10636.altinitytest (altinity build)) 2025.07.28 11:50:52.580514 [ 11839 ] {3c2bd241-15e2-4d71-84d6-e515aa48464c} executeQuery: Code: 210. DB::NetException: Connection reset by peer, while writing to socket ([::ffff:127.0.0.1]:9000 -> [::ffff:127.0.0.1]:58804). (NETWORK_ERROR) (version 25.3.6.10636.altinitytest (altinity build)) (from [::ffff:127.0.0.1]:58804) (comment: 03254_limit_by_with_offset_parallel_replicas.sh) (query 11, line 14) (in query: SELECT `__table1`.`a` AS `a` FROM `test_13`.`ties` AS `__table1` ORDER BY `__table1`.`a` ASC LIMIT _CAST(2, 'UInt64'), _CAST(3, 'UInt64') WITH TIES), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::NetException::NetException(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&) @ 0x000000000fd50fb5 3. /build/src/IO/WriteBufferFromPocoSocket.cpp:160: DB::WriteBufferFromPocoSocket::nextImpl() @ 0x000000000fd523f1 4. /build/src/IO/WriteBuffer.h:53: DB::WriteBuffer::next() @ 0x000000000a0755be 5. /build/src/Server/TCPHandler.cpp:1422: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x00000000168f181c 6. /build/src/Server/TCPHandler.cpp:678: DB::TCPHandler::runImpl() @ 0x00000000168e68e5 7. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 8. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 9. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 10. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 11. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 12. ? @ 0x00007fbc6213eac3 13. ? @ 0x00007fbc621d0850 2025.07.28 11:50:52.590246 [ 11839 ] {} TCPHandler: Code: 210. DB::NetException: Connection reset by peer, while writing to socket ([::ffff:127.0.0.1]:9000 -> [::ffff:127.0.0.1]:58804). (NETWORK_ERROR), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::NetException::NetException(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&) @ 0x000000000fd50fb5 3. /build/src/IO/WriteBufferFromPocoSocket.cpp:160: DB::WriteBufferFromPocoSocket::nextImpl() @ 0x000000000fd523f1 4. /build/src/IO/WriteBuffer.h:53: DB::WriteBuffer::next() @ 0x000000000a0755be 5. /build/src/Server/TCPHandler.cpp:1422: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x00000000168f181c 6. /build/src/Server/TCPHandler.cpp:678: DB::TCPHandler::runImpl() @ 0x00000000168e68e5 7. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 8. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 9. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 10. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 11. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 12. ? @ 0x00007fbc6213eac3 13. ? @ 0x00007fbc621d0850 2025.07.28 11:50:52.599683 [ 4462 ] {ab682514-a389-41df-97be-7ce703e19c58} void DB::TCPHandler::sendData(QueryState &, const Block &): Code: 210. DB::NetException: Connection reset by peer, while writing to socket ([::ffff:127.0.0.4]:9000 -> [::ffff:127.0.0.1]:36070). (NETWORK_ERROR), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::NetException::NetException(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&) @ 0x000000000fd50fb5 3. /build/src/IO/WriteBufferFromPocoSocket.cpp:160: DB::WriteBufferFromPocoSocket::nextImpl() @ 0x000000000fd523f1 4. /build/src/IO/WriteBuffer.h:53: DB::WriteBuffer::next() @ 0x000000000a0755be 5. /build/src/Server/TCPHandler.cpp:2490: DB::TCPHandler::sendData(DB::QueryState&, DB::Block const&) @ 0x00000000168fa306 6. /build/src/Server/TCPHandler.cpp:1266: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x00000000168f162c 7. /build/src/Server/TCPHandler.cpp:678: DB::TCPHandler::runImpl() @ 0x00000000168e68e5 8. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 9. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 10. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 11. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 12. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 13. ? @ 0x00007fbc6213eac3 14. ? @ 0x00007fbc621d0850 (version 25.3.6.10636.altinitytest (altinity build)) 2025.07.28 11:50:52.661895 [ 4462 ] {ab682514-a389-41df-97be-7ce703e19c58} executeQuery: Code: 210. DB::NetException: Connection reset by peer, while writing to socket ([::ffff:127.0.0.4]:9000 -> [::ffff:127.0.0.1]:36070). (NETWORK_ERROR) (version 25.3.6.10636.altinitytest (altinity build)) (from [::ffff:127.0.0.1]:36070) (comment: 03254_limit_by_with_offset_parallel_replicas.sh) (query 11, line 14) (in query: SELECT `__table1`.`a` AS `a` FROM `test_13`.`ties` AS `__table1` ORDER BY `__table1`.`a` ASC LIMIT _CAST(2, 'UInt64'), _CAST(3, 'UInt64') WITH TIES), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::NetException::NetException(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&) @ 0x000000000fd50fb5 3. /build/src/IO/WriteBufferFromPocoSocket.cpp:160: DB::WriteBufferFromPocoSocket::nextImpl() @ 0x000000000fd523f1 4. /build/src/IO/WriteBuffer.h:53: DB::WriteBuffer::next() @ 0x000000000a0755be 5. /build/src/Server/TCPHandler.cpp:2490: DB::TCPHandler::sendData(DB::QueryState&, DB::Block const&) @ 0x00000000168fa306 6. /build/src/Server/TCPHandler.cpp:1266: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x00000000168f162c 7. /build/src/Server/TCPHandler.cpp:678: DB::TCPHandler::runImpl() @ 0x00000000168e68e5 8. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 9. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 10. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 11. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 12. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 13. ? @ 0x00007fbc6213eac3 14. ? @ 0x00007fbc621d0850 2025.07.28 11:50:52.698048 [ 4462 ] {} TCPHandler: Code: 210. DB::NetException: Connection reset by peer, while writing to socket ([::ffff:127.0.0.4]:9000 -> [::ffff:127.0.0.1]:36070). (NETWORK_ERROR), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::NetException::NetException(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&) @ 0x000000000fd50fb5 3. /build/src/IO/WriteBufferFromPocoSocket.cpp:160: DB::WriteBufferFromPocoSocket::nextImpl() @ 0x000000000fd523f1 4. /build/src/IO/WriteBuffer.h:53: DB::WriteBuffer::next() @ 0x000000000a0755be 5. /build/src/Server/TCPHandler.cpp:2490: DB::TCPHandler::sendData(DB::QueryState&, DB::Block const&) @ 0x00000000168fa306 6. /build/src/Server/TCPHandler.cpp:1266: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x00000000168f162c 7. /build/src/Server/TCPHandler.cpp:678: DB::TCPHandler::runImpl() @ 0x00000000168e68e5 8. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 9. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 10. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 11. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 12. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 13. ? @ 0x00007fbc6213eac3 14. ? @ 0x00007fbc621d0850 2025.07.28 11:50:52.865867 [ 12754 ] {65d40407-603a-4d2d-98b7-82f35948dfd5} 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.6.10636.altinitytest (altinity build)) (from [::1]:60310) (comment: 02454_create_table_with_custom_disk.sh) (query 7, line 20) (in query: DETACH TABLE test;), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000000a074fcb 4. /build/src/Databases/DatabaseReplicated.cpp:1108: DB::DatabaseReplicated::checkQueryValid(std::shared_ptr const&, std::shared_ptr) const @ 0x0000000013d9ef48 5. /build/src/Databases/DatabaseReplicated.cpp:1130: DB::DatabaseReplicated::tryEnqueueReplicatedDDL(std::shared_ptr const&, std::shared_ptr, DB::QueryFlags) @ 0x0000000013d9f10b 6. /build/src/Interpreters/InterpreterDropQuery.cpp:226: DB::InterpreterDropQuery::executeToTableImpl(std::shared_ptr const&, DB::ASTDropQuery&, std::shared_ptr&, StrongTypedef, DB::UUIDTag>&) @ 0x0000000014914ed7 7. /build/src/Interpreters/InterpreterDropQuery.cpp:118: DB::InterpreterDropQuery::executeToTable(DB::ASTDropQuery&) @ 0x00000000149137b4 8. /build/src/Interpreters/InterpreterDropQuery.cpp:91: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000014912f07 9. /build/src/Interpreters/InterpreterDropQuery.cpp:72: DB::InterpreterDropQuery::execute() @ 0x0000000014912b65 10. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88dc9 11. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 12. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 13. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 14. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 15. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 16. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 17. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 18. ? @ 0x00007fbc6213eac3 19. ? @ 0x00007fbc621d0850 2025.07.28 11:50:52.880891 [ 12754 ] {} 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. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000000a074fcb 4. /build/src/Databases/DatabaseReplicated.cpp:1108: DB::DatabaseReplicated::checkQueryValid(std::shared_ptr const&, std::shared_ptr) const @ 0x0000000013d9ef48 5. /build/src/Databases/DatabaseReplicated.cpp:1130: DB::DatabaseReplicated::tryEnqueueReplicatedDDL(std::shared_ptr const&, std::shared_ptr, DB::QueryFlags) @ 0x0000000013d9f10b 6. /build/src/Interpreters/InterpreterDropQuery.cpp:226: DB::InterpreterDropQuery::executeToTableImpl(std::shared_ptr const&, DB::ASTDropQuery&, std::shared_ptr&, StrongTypedef, DB::UUIDTag>&) @ 0x0000000014914ed7 7. /build/src/Interpreters/InterpreterDropQuery.cpp:118: DB::InterpreterDropQuery::executeToTable(DB::ASTDropQuery&) @ 0x00000000149137b4 8. /build/src/Interpreters/InterpreterDropQuery.cpp:91: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000014912f07 9. /build/src/Interpreters/InterpreterDropQuery.cpp:72: DB::InterpreterDropQuery::execute() @ 0x0000000014912b65 10. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88dc9 11. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 12. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 13. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 14. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 15. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 16. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 17. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 18. ? @ 0x00007fbc6213eac3 19. ? @ 0x00007fbc621d0850 2025.07.28 11:50:52.967633 [ 4243 ] {cc65b808-c327-4076-87ea-80c968e8d19e} executeQuery: Code: 80. DB::Exception: It's not initial query. ON CLUSTER is not allowed for Replicated database. (INCORRECT_QUERY) (version 25.3.6.10636.altinitytest (altinity build)) (from 0.0.0.0:0) (comment: 02541_lightweight_delete_on_cluster.sql) (in query: /* ddl_entry=query-0000000000 */ CREATE TABLE test_izx6q3o0.t1_local UUID 'c0be61c5-2316-486b-beae-2528ebde28c1' (`partition_col_1` String, `tc1` Int32, `tc2` Int32) ENGINE = MergeTree PARTITION BY partition_col_1 ORDER BY tc1 SETTINGS index_granularity = 61237, min_bytes_for_wide_part = 0, ratio_of_defaults_for_sparse_serialization = 0.005984482355415821, 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 = 212026675, compact_parts_max_granules_to_buffer = 256, compact_parts_merge_max_bytes_to_prefetch_part = 1251710, merge_max_block_size = 10822, old_parts_lifetime = 476., prefer_fetch_merged_part_size_threshold = 1, vertical_merge_algorithm_min_rows_to_activate = 751344, vertical_merge_algorithm_min_columns_to_activate = 100, min_merge_bytes_to_use_direct_io = 4149987715, index_granularity_bytes = 17873827, 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 = 58401, primary_key_compress_block_size = 97363, 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. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000000a074fcb 4. /build/src/Databases/DatabaseReplicated.cpp:1128: DB::DatabaseReplicated::tryEnqueueReplicatedDDL(std::shared_ptr const&, std::shared_ptr, DB::QueryFlags) @ 0x0000000013da037d 5. /build/src/Interpreters/InterpreterCreateQuery.cpp:1723: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000148f96f8 6. /build/src/Interpreters/InterpreterCreateQuery.cpp:2352: DB::InterpreterCreateQuery::execute() @ 0x0000000014905a41 7. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88dc9 8. /build/src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x0000000014c8ca7b 9. /build/src/Interpreters/DDLWorker.cpp:510: DB::DDLWorker::tryExecuteQuery(DB::DDLTaskBase&, std::shared_ptr const&, bool) @ 0x00000000144dab9e 10. /build/src/Interpreters/DDLWorker.cpp:675: DB::DDLWorker::processTask(DB::DDLTaskBase&, std::shared_ptr const&, bool) @ 0x00000000144d8ffe 11. /build/src/Interpreters/DDLWorker.cpp:453: DB::DDLWorker::scheduleTasks(bool) @ 0x00000000144d6562 12. /build/src/Interpreters/DDLWorker.cpp:1203: DB::DDLWorker::runMainThread() @ 0x00000000144cf6ec 13. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl(void (DB::DDLWorker::*&&)(), DB::DDLWorker*&&)::'lambda'()::operator()() @ 0x00000000144ead03 14. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc3d92 15. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fcca080 16. ? @ 0x00007fbc6213eac3 17. ? @ 0x00007fbc621d0850 2025.07.28 11:50:52.971961 [ 4243 ] {cc65b808-c327-4076-87ea-80c968e8d19e} DDLWorker: Query /* ddl_entry=query-0000000000 */ CREATE TABLE test_izx6q3o0.t1_local UUID 'c0be61c5-2316-486b-beae-2528ebde28c1' (`partition_col_1` String, `tc1` Int32, `tc2` Int32) ENGINE = MergeTree PARTITION BY partition_col_1 ORDER BY tc1 SETTINGS index_granularity = 61237, min_bytes_for_wide_part = 0, ratio_of_defaults_for_sparse_serialization = 0.005984482355415821, 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 = 212026675, compact_parts_max_granules_to_buffer = 256, compact_parts_merge_max_bytes_to_prefetch_part = 1251710, merge_max_block_size = 10822, old_parts_lifetime = 476., prefer_fetch_merged_part_size_threshold = 1, vertical_merge_algorithm_min_rows_to_activate = 751344, vertical_merge_algorithm_min_columns_to_activate = 100, min_merge_bytes_to_use_direct_io = 4149987715, index_granularity_bytes = 17873827, 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 = 58401, primary_key_compress_block_size = 97363, use_primary_key_cache = false, prewarm_primary_key_cache = false, prewarm_mark_cache = true 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. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000000a074fcb 4. /build/src/Databases/DatabaseReplicated.cpp:1128: DB::DatabaseReplicated::tryEnqueueReplicatedDDL(std::shared_ptr const&, std::shared_ptr, DB::QueryFlags) @ 0x0000000013da037d 5. /build/src/Interpreters/InterpreterCreateQuery.cpp:1723: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000148f96f8 6. /build/src/Interpreters/InterpreterCreateQuery.cpp:2352: DB::InterpreterCreateQuery::execute() @ 0x0000000014905a41 7. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88dc9 8. /build/src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x0000000014c8ca7b 9. /build/src/Interpreters/DDLWorker.cpp:510: DB::DDLWorker::tryExecuteQuery(DB::DDLTaskBase&, std::shared_ptr const&, bool) @ 0x00000000144dab9e 10. /build/src/Interpreters/DDLWorker.cpp:675: DB::DDLWorker::processTask(DB::DDLTaskBase&, std::shared_ptr const&, bool) @ 0x00000000144d8ffe 11. /build/src/Interpreters/DDLWorker.cpp:453: DB::DDLWorker::scheduleTasks(bool) @ 0x00000000144d6562 12. /build/src/Interpreters/DDLWorker.cpp:1203: DB::DDLWorker::runMainThread() @ 0x00000000144cf6ec 13. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl(void (DB::DDLWorker::*&&)(), DB::DDLWorker*&&)::'lambda'()::operator()() @ 0x00000000144ead03 14. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc3d92 15. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fcca080 16. ? @ 0x00007fbc6213eac3 17. ? @ 0x00007fbc621d0850 (version 25.3.6.10636.altinitytest (altinity build)) 2025.07.28 11:50:52.981923 [ 3333 ] {} 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. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000fccaeeb 4. /build/src/Common/ThreadPool.cpp:275: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000fccc813 5. /build/src/Common/ThreadPool.cpp:323: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fcc7bbc 6. /build/src/Common/ThreadPool.cpp:494: ThreadPoolImpl>::scheduleOrThrowOnError(std::function, Priority) @ 0x000000000fcc7a0e 7. /build/src/Common/threadPoolCallbackRunner.h:188: DB::ThreadPoolCallbackRunnerLocal>, std::function>::operator()(std::function&&, Priority, std::optional) @ 0x00000000119df78e 8. /build/src/Interpreters/DatabaseCatalog.cpp:1360: DB::DatabaseCatalog::dropTablesParallel(std::vector, std::allocator>>) @ 0x00000000144fcff9 9. /build/src/Interpreters/DatabaseCatalog.cpp:1382: DB::DatabaseCatalog::dropTableDataTask() @ 0x00000000144fd4fc 10. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000139630d4 11. /build/src/Core/BackgroundSchedulePool.cpp:308: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001396616a 12. /build/src/Core/BackgroundSchedulePool.cpp:171: void std::__function::__policy_invoker::__call_impl[abi:se190107]::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_1>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_1&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001396690a 13. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc3d92 14. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fcca080 15. ? @ 0x00007fbc6213eac3 16. ? @ 0x00007fbc621d0850 (version 25.3.6.10636.altinitytest (altinity build)) 2025.07.28 11:50:53.210779 [ 5029 ] {92b455cd-e3ae-459d-84f8-b7085367be7f} executeQuery: Code: 159. DB::Exception: Timeout exceeded: elapsed 62485.558846 ms, maximum: 60000 ms. (TIMEOUT_EXCEEDED) (version 25.3.6.10636.altinitytest (altinity build)) (from [::1]:33804) (comment: 03227_distinct_dynamic_types_json_paths.sql) (query 8, line 11) (in query: insert into test_json_dynamic_aggregate_functions select toJSONString(map('a' || number % 13, multiIf(number % 5 == 0, NULL, number % 5 == 1, number::UInt32, number % 5 == 2, 'str_' || number, number % 5 == 3, range(number % 5), toBool(number % 2)))) from numbers(100000);), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, double&&, long&&) @ 0x0000000013bb358b 4. /build/src/QueryPipeline/ExecutionSpeedLimits.cpp:113: DB::ExecutionSpeedLimits::checkTimeLimit(unsigned long const&, DB::OverflowMode) const @ 0x0000000013bb28cc 5. /build/src/Interpreters/ProcessList.cpp:559: DB::QueryStatus::checkTimeLimit() @ 0x0000000014a4c2df 6. /build/src/Processors/Executors/PipelineExecutor.cpp:206: DB::PipelineExecutor::finalizeExecution() @ 0x00000000169b13ba 7. /build/src/Processors/Executors/PipelineExecutor.cpp:153: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x00000000169b0584 8. /build/src/Processors/Executors/CompletedPipelineExecutor.cpp:42: void std::__function::__policy_invoker::__call_impl[abi:se190107]::ThreadFromGlobalPoolImpl(DB::CompletedPipelineExecutor::execute()::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169af7e1 9. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc3d92 10. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fcca080 11. ? @ 0x00007fbc6213eac3 12. ? @ 0x00007fbc621d0850 2025.07.28 11:50:53.234290 [ 11826 ] {dfcda8ab-96b8-4125-99e1-ad51f669bee0} 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.6.10636.altinitytest (altinity build)). (INCORRECT_QUERY) (version 25.3.6.10636.altinitytest (altinity build)) (from 0.0.0.0:0) (comment: 02541_lightweight_delete_on_cluster.sql) (in query: /* ddl_entry=query-0000000002 */ CREATE TABLE test_izx6q3o0.t1_local UUID 'c0be61c5-2316-486b-beae-2528ebde28c1' ON CLUSTER test_shard_localhost (`partition_col_1` String, `tc1` Int32, `tc2` Int32) ENGINE = MergeTree PARTITION BY partition_col_1 ORDER BY tc1 SETTINGS index_granularity = 61237, min_bytes_for_wide_part = 0, ratio_of_defaults_for_sparse_serialization = 0.005984482355415821, 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 = 212026675, compact_parts_max_granules_to_buffer = 256, compact_parts_merge_max_bytes_to_prefetch_part = 1251710, merge_max_block_size = 10822, old_parts_lifetime = 476., prefer_fetch_merged_part_size_threshold = 1, vertical_merge_algorithm_min_rows_to_activate = 751344, vertical_merge_algorithm_min_columns_to_activate = 100, min_merge_bytes_to_use_direct_io = 4149987715, index_granularity_bytes = 17873827, 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 = 58401, primary_key_compress_block_size = 97363, 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. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&, unsigned short&, String const&) @ 0x0000000014c7c06b 4. /build/src/Interpreters/DDLOnClusterQueryStatusSource.cpp:124: DB::DDLOnClusterQueryStatusSource::handleNonZeroStatusCode(DB::ExecutionStatus const&, String const&) @ 0x0000000014c7ba94 5. /build/src/Interpreters/DistributedQueryStatusSource.cpp:268: DB::DistributedQueryStatusSource::generate() @ 0x000000001450f1c6 6. /build/src/Processors/ISource.cpp:139: DB::ISource::tryGenerate() @ 0x00000000169a24fa 7. /build/src/Processors/ISource.cpp:108: DB::ISource::work() @ 0x00000000169a21e7 8. /build/src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x00000000169bd00f 9. /build/src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x00000000169b2105 10. /build/src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeSingleThread(unsigned long) @ 0x00000000169b23be 11. /build/src/Processors/Executors/PipelineExecutor.cpp:454: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x00000000169b0be7 12. /build/src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x00000000169b03f4 13. /build/src/Processors/Executors/CompletedPipelineExecutor.cpp:105: DB::CompletedPipelineExecutor::execute() @ 0x00000000169af3c4 14. /build/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&)>) @ 0x0000000014c8d123 15. /build/src/Interpreters/DDLWorker.cpp:510: DB::DDLWorker::tryExecuteQuery(DB::DDLTaskBase&, std::shared_ptr const&, bool) @ 0x00000000144dab9e 16. /build/src/Interpreters/DDLWorker.cpp:675: DB::DDLWorker::processTask(DB::DDLTaskBase&, std::shared_ptr const&, bool) @ 0x00000000144d8ffe 17. /build/src/Databases/DatabaseReplicatedWorker.cpp:372: DB::DatabaseReplicatedDDLWorker::tryEnqueueAndExecuteEntry(DB::DDLLogEntry&, std::shared_ptr, bool) @ 0x0000000013dc29ab 18. /build/src/Databases/DatabaseReplicated.cpp:1139: DB::DatabaseReplicated::tryEnqueueReplicatedDDL(std::shared_ptr const&, std::shared_ptr, DB::QueryFlags) @ 0x0000000013d9f73c 19. /build/src/Interpreters/InterpreterCreateQuery.cpp:1723: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000148f96f8 20. /build/src/Interpreters/InterpreterCreateQuery.cpp:2352: DB::InterpreterCreateQuery::execute() @ 0x0000000014905a41 21. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88dc9 22. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 23. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 24. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 25. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 26. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 27. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 28. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 29. ? @ 0x00007fbc6213eac3 30. ? @ 0x00007fbc621d0850 2025.07.28 11:50:53.270707 [ 5029 ] {} TCPHandler: Code: 159. DB::Exception: Timeout exceeded: elapsed 62485.558846 ms, maximum: 60000 ms. (TIMEOUT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, double&&, long&&) @ 0x0000000013bb358b 4. /build/src/QueryPipeline/ExecutionSpeedLimits.cpp:113: DB::ExecutionSpeedLimits::checkTimeLimit(unsigned long const&, DB::OverflowMode) const @ 0x0000000013bb28cc 5. /build/src/Interpreters/ProcessList.cpp:559: DB::QueryStatus::checkTimeLimit() @ 0x0000000014a4c2df 6. /build/src/Processors/Executors/PipelineExecutor.cpp:206: DB::PipelineExecutor::finalizeExecution() @ 0x00000000169b13ba 7. /build/src/Processors/Executors/PipelineExecutor.cpp:153: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x00000000169b0584 8. /build/src/Processors/Executors/CompletedPipelineExecutor.cpp:42: void std::__function::__policy_invoker::__call_impl[abi:se190107]::ThreadFromGlobalPoolImpl(DB::CompletedPipelineExecutor::execute()::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169af7e1 9. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc3d92 10. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fcca080 11. ? @ 0x00007fbc6213eac3 12. ? @ 0x00007fbc621d0850 Job's origin stack trace: 0. /build/src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000000fc33b84 1. /build/src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000000fcc2ea7 2. /build/src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fcc535c 3. /build/src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000000fcc584d 4. /build/src/Common/ThreadPool.h:279: DB::CompletedPipelineExecutor::execute() @ 0x00000000169af267 5. /build/src/Server/TCPHandler.cpp:707: DB::TCPHandler::runImpl() @ 0x00000000168e6b2e 6. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 7. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 8. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 9. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 10. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 11. ? @ 0x00007fbc6213eac3 12. ? @ 0x00007fbc621d0850 2025.07.28 11:50:53.285684 [ 11826 ] {dfcda8ab-96b8-4125-99e1-ad51f669bee0} 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.6.10636.altinitytest (altinity build)). (INCORRECT_QUERY) (version 25.3.6.10636.altinitytest (altinity build)) (from [::1]:57808) (comment: 02541_lightweight_delete_on_cluster.sql) (query 2, line 6) (in query: CREATE TABLE t1_local ON CLUSTER test_shard_localhost (`partition_col_1` String, `tc1` int, `tc2` int) ENGINE = MergeTree PARTITION BY partition_col_1 ORDER BY tc1 SETTINGS index_granularity = 61237, min_bytes_for_wide_part = 0, ratio_of_defaults_for_sparse_serialization = 0.005984482355415821, 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 = 212026675, compact_parts_max_granules_to_buffer = 256, compact_parts_merge_max_bytes_to_prefetch_part = 1251710, merge_max_block_size = 10822, old_parts_lifetime = 476., prefer_fetch_merged_part_size_threshold = 1, vertical_merge_algorithm_min_rows_to_activate = 751344, vertical_merge_algorithm_min_columns_to_activate = 100, min_merge_bytes_to_use_direct_io = 4149987715, index_granularity_bytes = 17873827, 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 = 58401, primary_key_compress_block_size = 97363, 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. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&, unsigned short&, String const&) @ 0x0000000014c7c06b 4. /build/src/Interpreters/DDLOnClusterQueryStatusSource.cpp:124: DB::DDLOnClusterQueryStatusSource::handleNonZeroStatusCode(DB::ExecutionStatus const&, String const&) @ 0x0000000014c7ba94 5. /build/src/Interpreters/DistributedQueryStatusSource.cpp:268: DB::DistributedQueryStatusSource::generate() @ 0x000000001450f1c6 6. /build/src/Processors/ISource.cpp:139: DB::ISource::tryGenerate() @ 0x00000000169a24fa 7. /build/src/Processors/ISource.cpp:108: DB::ISource::work() @ 0x00000000169a21e7 8. /build/src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x00000000169bd00f 9. /build/src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x00000000169b2105 10. /build/src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeSingleThread(unsigned long) @ 0x00000000169b23be 11. /build/src/Processors/Executors/PipelineExecutor.cpp:454: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x00000000169b0be7 12. /build/src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x00000000169b03f4 13. /build/src/Processors/Executors/CompletedPipelineExecutor.cpp:105: DB::CompletedPipelineExecutor::execute() @ 0x00000000169af3c4 14. /build/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&)>) @ 0x0000000014c8d123 15. /build/src/Interpreters/DDLWorker.cpp:510: DB::DDLWorker::tryExecuteQuery(DB::DDLTaskBase&, std::shared_ptr const&, bool) @ 0x00000000144dab9e 16. /build/src/Interpreters/DDLWorker.cpp:675: DB::DDLWorker::processTask(DB::DDLTaskBase&, std::shared_ptr const&, bool) @ 0x00000000144d8ffe 17. /build/src/Databases/DatabaseReplicatedWorker.cpp:372: DB::DatabaseReplicatedDDLWorker::tryEnqueueAndExecuteEntry(DB::DDLLogEntry&, std::shared_ptr, bool) @ 0x0000000013dc29ab 18. /build/src/Databases/DatabaseReplicated.cpp:1139: DB::DatabaseReplicated::tryEnqueueReplicatedDDL(std::shared_ptr const&, std::shared_ptr, DB::QueryFlags) @ 0x0000000013d9f73c 19. /build/src/Interpreters/InterpreterCreateQuery.cpp:1723: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000148f96f8 20. /build/src/Interpreters/InterpreterCreateQuery.cpp:2352: DB::InterpreterCreateQuery::execute() @ 0x0000000014905a41 21. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88dc9 22. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 23. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 24. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 25. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 26. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 27. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 28. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 29. ? @ 0x00007fbc6213eac3 30. ? @ 0x00007fbc621d0850 2025.07.28 11:50:53.314772 [ 11826 ] {} 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.6.10636.altinitytest (altinity build)). (INCORRECT_QUERY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&, unsigned short&, String const&) @ 0x0000000014c7c06b 4. /build/src/Interpreters/DDLOnClusterQueryStatusSource.cpp:124: DB::DDLOnClusterQueryStatusSource::handleNonZeroStatusCode(DB::ExecutionStatus const&, String const&) @ 0x0000000014c7ba94 5. /build/src/Interpreters/DistributedQueryStatusSource.cpp:268: DB::DistributedQueryStatusSource::generate() @ 0x000000001450f1c6 6. /build/src/Processors/ISource.cpp:139: DB::ISource::tryGenerate() @ 0x00000000169a24fa 7. /build/src/Processors/ISource.cpp:108: DB::ISource::work() @ 0x00000000169a21e7 8. /build/src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x00000000169bd00f 9. /build/src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x00000000169b2105 10. /build/src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeSingleThread(unsigned long) @ 0x00000000169b23be 11. /build/src/Processors/Executors/PipelineExecutor.cpp:454: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x00000000169b0be7 12. /build/src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x00000000169b03f4 13. /build/src/Processors/Executors/CompletedPipelineExecutor.cpp:105: DB::CompletedPipelineExecutor::execute() @ 0x00000000169af3c4 14. /build/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&)>) @ 0x0000000014c8d123 15. /build/src/Interpreters/DDLWorker.cpp:510: DB::DDLWorker::tryExecuteQuery(DB::DDLTaskBase&, std::shared_ptr const&, bool) @ 0x00000000144dab9e 16. /build/src/Interpreters/DDLWorker.cpp:675: DB::DDLWorker::processTask(DB::DDLTaskBase&, std::shared_ptr const&, bool) @ 0x00000000144d8ffe 17. /build/src/Databases/DatabaseReplicatedWorker.cpp:372: DB::DatabaseReplicatedDDLWorker::tryEnqueueAndExecuteEntry(DB::DDLLogEntry&, std::shared_ptr, bool) @ 0x0000000013dc29ab 18. /build/src/Databases/DatabaseReplicated.cpp:1139: DB::DatabaseReplicated::tryEnqueueReplicatedDDL(std::shared_ptr const&, std::shared_ptr, DB::QueryFlags) @ 0x0000000013d9f73c 19. /build/src/Interpreters/InterpreterCreateQuery.cpp:1723: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000148f96f8 20. /build/src/Interpreters/InterpreterCreateQuery.cpp:2352: DB::InterpreterCreateQuery::execute() @ 0x0000000014905a41 21. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88dc9 22. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 23. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 24. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 25. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 26. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 27. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 28. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 29. ? @ 0x00007fbc6213eac3 30. ? @ 0x00007fbc621d0850 2025.07.28 11:50:55.495718 [ 4508 ] {b975d8f3-c948-4651-af49-cc1aa3ad3f33} executeQuery: Code: 439. DB::Exception: Cannot schedule a task: failed to start the thread (threads=1, jobs=1). (CANNOT_SCHEDULE_TASK) (version 25.3.6.10636.altinitytest (altinity build)) (from [::ffff:127.0.0.1]:49432) (comment: 01848_partition_value_column.sql) (query 7, line 11) (in query: SELECT count() AS `count()` FROM `test_7`.`tbl` AS `__table1` WHERE (`__table1`.`_partition_value`.1) = '2021-04-01'), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000fccaeeb 4. /build/src/Common/ThreadPool.cpp:275: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000fccc813 5. /build/src/Common/ThreadPool.cpp:308: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fcc8286 6. /build/src/Common/ThreadPool.cpp:494: ThreadPoolImpl>::scheduleOrThrowOnError(std::function, Priority) @ 0x000000000fcc7a0e 7. /build/src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::spawnThreadsImpl() @ 0x00000000169b2c0c 8. /build/src/Processors/Executors/PipelineExecutor.cpp:394: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x00000000169b20b2 9. /build/src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeSingleThread(unsigned long) @ 0x00000000169b23be 10. /build/src/Processors/Executors/PipelineExecutor.cpp:416: void std::__function::__policy_invoker::__call_impl[abi:se190107]>(std::__function::__policy_storage const*) @ 0x00000000169b2e3f 11. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc6653 12. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000000fccc4c3 13. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc3d92 14. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fcca080 15. ? @ 0x00007fbc6213eac3 16. ? @ 0x00007fbc621d0850 2025.07.28 11:50:55.520729 [ 4508 ] {} 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. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000fccaeeb 4. /build/src/Common/ThreadPool.cpp:275: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000fccc813 5. /build/src/Common/ThreadPool.cpp:308: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fcc8286 6. /build/src/Common/ThreadPool.cpp:494: ThreadPoolImpl>::scheduleOrThrowOnError(std::function, Priority) @ 0x000000000fcc7a0e 7. /build/src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::spawnThreadsImpl() @ 0x00000000169b2c0c 8. /build/src/Processors/Executors/PipelineExecutor.cpp:394: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x00000000169b20b2 9. /build/src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeSingleThread(unsigned long) @ 0x00000000169b23be 10. /build/src/Processors/Executors/PipelineExecutor.cpp:416: void std::__function::__policy_invoker::__call_impl[abi:se190107]>(std::__function::__policy_storage const*) @ 0x00000000169b2e3f 11. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc6653 12. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000000fccc4c3 13. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc3d92 14. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fcca080 15. ? @ 0x00007fbc6213eac3 16. ? @ 0x00007fbc621d0850 Job's origin stack trace: 0. /build/src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000000fc33b84 1. /build/src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000000fcc2ea7 2. /build/src/Common/ThreadPool.cpp:401: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fcc7f1c 3. /build/src/Common/ThreadPool.cpp:494: ThreadPoolImpl>::scheduleOrThrowOnError(std::function, Priority) @ 0x000000000fcc7a0e 4. /build/src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::spawnThreadsImpl() @ 0x00000000169b2c0c 5. /build/src/Processors/Executors/PipelineExecutor.cpp:394: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x00000000169b0ba7 6. /build/src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x00000000169b03f4 7. /build/src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:se190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169bfeab 8. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc3d92 9. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fcca080 10. ? @ 0x00007fbc6213eac3 11. ? @ 0x00007fbc621d0850 Job's origin stack trace: 0. /build/src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000000fc33b84 1. /build/src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000000fcc2ea7 2. /build/src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fcc535c 3. /build/src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000000fcc584d 4. /build/src/Common/ThreadPool.h:279: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x00000000169bf193 5. /build/src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x00000000169bf518 6. /build/src/Server/TCPHandler.cpp:1237: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x00000000168f1525 7. /build/src/Server/TCPHandler.cpp:678: DB::TCPHandler::runImpl() @ 0x00000000168e68e5 8. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 9. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 10. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 11. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 12. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 13. ? @ 0x00007fbc6213eac3 14. ? @ 0x00007fbc621d0850 2025.07.28 11:50:55.559555 [ 12807 ] {a1a4993e-a22d-41aa-b155-caf718140aff} executeQuery: Code: 439. DB::Exception: Received from 127.0.0.8:9000. DB::Exception: Cannot schedule a task: failed to start the thread (threads=1, jobs=1). Stack trace: 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000fccaeeb 4. /build/src/Common/ThreadPool.cpp:275: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000fccc813 5. /build/src/Common/ThreadPool.cpp:308: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fcc8286 6. /build/src/Common/ThreadPool.cpp:494: ThreadPoolImpl>::scheduleOrThrowOnError(std::function, Priority) @ 0x000000000fcc7a0e 7. /build/src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::spawnThreadsImpl() @ 0x00000000169b2c0c 8. /build/src/Processors/Executors/PipelineExecutor.cpp:394: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x00000000169b20b2 9. /build/src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeSingleThread(unsigned long) @ 0x00000000169b23be 10. /build/src/Processors/Executors/PipelineExecutor.cpp:416: void std::__function::__policy_invoker::__call_impl[abi:se190107]>(std::__function::__policy_storage const*) @ 0x00000000169b2e3f 11. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc6653 12. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000000fccc4c3 13. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc3d92 14. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fcca080 15. ? @ 0x00007fbc6213eac3 16. ? @ 0x00007fbc621d0850 Job's origin stack trace: 0. /build/src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000000fc33b84 1. /build/src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000000fcc2ea7 2. /build/src/Common/ThreadPool.cpp:401: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fcc7f1c 3. /build/src/Common/ThreadPool.cpp:494: ThreadPoolImpl>::scheduleOrThrowOnError(std::function, Priority) @ 0x000000000fcc7a0e 4. /build/src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::spawnThreadsImpl() @ 0x00000000169b2c0c 5. /build/src/Processors/Executors/PipelineExecutor.cpp:394: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x00000000169b0ba7 6. /build/src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x00000000169b03f4 7. /build/src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:se190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169bfeab 8. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc3d92 9. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fcca080 10. ? @ 0x00007fbc6213eac3 11. ? @ 0x00007fbc621d0850 Job's origin stack trace: 0. /build/src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000000fc33b84 1. /build/src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000000fcc2ea7 2. /build/src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fcc535c 3. /build/src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000000fcc584d 4. /build/src/Common/ThreadPool.h:279: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x00000000169bf193 5. /build/src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x00000000169bf518 6. /build/src/Server/TCPHandler.cpp:1237: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x00000000168f1525 7. /build/src/Server/TCPHandler.cpp:678: DB::TCPHandler::runImpl() @ 0x00000000168e68e5 8. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 9. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 10. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 11. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 12. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 13. ? @ 0x00007fbc6213eac3 14. ? @ 0x00007fbc621d0850 : While executing Remote. (CANNOT_SCHEDULE_TASK) (version 25.3.6.10636.altinitytest (altinity build)) (from [::1]:57786) (comment: 01848_partition_value_column.sql) (query 7, line 11) (in query: select count() from tbl where _partition_value.1 = '2021-04-01' settings max_rows_to_read = 4;), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:111: DB::readException(DB::ReadBuffer&, String const&, bool) @ 0x000000000fc6e157 3. /build/src/Client/Connection.cpp:1445: DB::Connection::receiveException() const @ 0x00000000167d4127 4. /build/src/Client/Connection.cpp:1274: DB::Connection::receivePacket() @ 0x00000000167db312 5. /build/src/Client/MultiplexedConnections.cpp:380: DB::MultiplexedConnections::receivePacketUnlocked(std::function) @ 0x00000000168163a9 6. /build/src/QueryPipeline/RemoteQueryExecutorReadContext.cpp:67: DB::RemoteQueryExecutorReadContext::Task::run(std::function, std::function) @ 0x0000000013bd23fe 7. /build/src/Common/AsyncTaskExecutor.cpp:89: DB::AsyncTaskExecutor::Routine::operator()(std::function) @ 0x0000000013bd1892 8. /build/src/Common/Fiber.h:76: boost::context::detail::fiber_record>::run(void*) @ 0x0000000013bd16fa 9. /build/contrib/boost/boost/context/fiber_fcontext.hpp:97: void boost::context::detail::fiber_entry>>(boost::context::detail::transfer_t) @ 0x0000000013bd1621 2025.07.28 11:50:55.649807 [ 12807 ] {} TCPHandler: Code: 439. DB::Exception: Received from 127.0.0.8:9000. DB::Exception: Cannot schedule a task: failed to start the thread (threads=1, jobs=1). Stack trace: 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000fccaeeb 4. /build/src/Common/ThreadPool.cpp:275: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000fccc813 5. /build/src/Common/ThreadPool.cpp:308: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fcc8286 6. /build/src/Common/ThreadPool.cpp:494: ThreadPoolImpl>::scheduleOrThrowOnError(std::function, Priority) @ 0x000000000fcc7a0e 7. /build/src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::spawnThreadsImpl() @ 0x00000000169b2c0c 8. /build/src/Processors/Executors/PipelineExecutor.cpp:394: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x00000000169b20b2 9. /build/src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeSingleThread(unsigned long) @ 0x00000000169b23be 10. /build/src/Processors/Executors/PipelineExecutor.cpp:416: void std::__function::__policy_invoker::__call_impl[abi:se190107]>(std::__function::__policy_storage const*) @ 0x00000000169b2e3f 11. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc6653 12. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000000fccc4c3 13. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc3d92 14. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fcca080 15. ? @ 0x00007fbc6213eac3 16. ? @ 0x00007fbc621d0850 Job's origin stack trace: 0. /build/src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000000fc33b84 1. /build/src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000000fcc2ea7 2. /build/src/Common/ThreadPool.cpp:401: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fcc7f1c 3. /build/src/Common/ThreadPool.cpp:494: ThreadPoolImpl>::scheduleOrThrowOnError(std::function, Priority) @ 0x000000000fcc7a0e 4. /build/src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::spawnThreadsImpl() @ 0x00000000169b2c0c 5. /build/src/Processors/Executors/PipelineExecutor.cpp:394: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x00000000169b0ba7 6. /build/src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x00000000169b03f4 7. /build/src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:se190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169bfeab 8. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc3d92 9. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fcca080 10. ? @ 0x00007fbc6213eac3 11. ? @ 0x00007fbc621d0850 Job's origin stack trace: 0. /build/src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000000fc33b84 1. /build/src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000000fcc2ea7 2. /build/src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fcc535c 3. /build/src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000000fcc584d 4. /build/src/Common/ThreadPool.h:279: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x00000000169bf193 5. /build/src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x00000000169bf518 6. /build/src/Server/TCPHandler.cpp:1237: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x00000000168f1525 7. /build/src/Server/TCPHandler.cpp:678: DB::TCPHandler::runImpl() @ 0x00000000168e68e5 8. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 9. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 10. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 11. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 12. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 13. ? @ 0x00007fbc6213eac3 14. ? @ 0x00007fbc621d0850 : While executing Remote. (CANNOT_SCHEDULE_TASK), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:111: DB::readException(DB::ReadBuffer&, String const&, bool) @ 0x000000000fc6e157 3. /build/src/Client/Connection.cpp:1445: DB::Connection::receiveException() const @ 0x00000000167d4127 4. /build/src/Client/Connection.cpp:1274: DB::Connection::receivePacket() @ 0x00000000167db312 5. /build/src/Client/MultiplexedConnections.cpp:380: DB::MultiplexedConnections::receivePacketUnlocked(std::function) @ 0x00000000168163a9 6. /build/src/QueryPipeline/RemoteQueryExecutorReadContext.cpp:67: DB::RemoteQueryExecutorReadContext::Task::run(std::function, std::function) @ 0x0000000013bd23fe 7. /build/src/Common/AsyncTaskExecutor.cpp:89: DB::AsyncTaskExecutor::Routine::operator()(std::function) @ 0x0000000013bd1892 8. /build/src/Common/Fiber.h:76: boost::context::detail::fiber_record>::run(void*) @ 0x0000000013bd16fa 9. /build/contrib/boost/boost/context/fiber_fcontext.hpp:97: void boost::context::detail::fiber_entry>>(boost::context::detail::transfer_t) @ 0x0000000013bd1621 Job's origin stack trace: 0. /build/src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000000fc33b84 1. /build/src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000000fcc2ea7 2. /build/src/Common/ThreadPool.cpp:401: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fcc7f1c 3. /build/src/Common/ThreadPool.cpp:494: ThreadPoolImpl>::scheduleOrThrowOnError(std::function, Priority) @ 0x000000000fcc7a0e 4. /build/src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::spawnThreadsImpl() @ 0x00000000169b2c0c 5. /build/src/Processors/Executors/PipelineExecutor.cpp:394: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x00000000169b0ba7 6. /build/src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x00000000169b03f4 7. /build/src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:se190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169bfeab 8. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc3d92 9. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fcca080 10. ? @ 0x00007fbc6213eac3 11. ? @ 0x00007fbc621d0850 Job's origin stack trace: 0. /build/src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000000fc33b84 1. /build/src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000000fcc2ea7 2. /build/src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fcc535c 3. /build/src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000000fcc584d 4. /build/src/Common/ThreadPool.h:279: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x00000000169bf193 5. /build/src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x00000000169bf518 6. /build/src/Server/TCPHandler.cpp:1237: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x00000000168f1525 7. /build/src/Server/TCPHandler.cpp:678: DB::TCPHandler::runImpl() @ 0x00000000168e68e5 8. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 9. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 10. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 11. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 12. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 13. ? @ 0x00007fbc6213eac3 14. ? @ 0x00007fbc621d0850 2025.07.28 11:50:56.653190 [ 6322 ] {2bd4a807-f9a9-4d49-ba65-e302eae3c267} executeQuery: Code: 80. DB::Exception: It's not initial query. ON CLUSTER is not allowed for Replicated database. (INCORRECT_QUERY) (version 25.3.6.10636.altinitytest (altinity build)) (from [::1]:60572) (comment: 03035_materialized_primary_key.sql) (in query: DROP DATABASE IF EXISTS test_wmdv7jwn SYNC ), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000000a074fcb 4. /build/src/Databases/DatabaseReplicated.cpp:1128: DB::DatabaseReplicated::tryEnqueueReplicatedDDL(std::shared_ptr const&, std::shared_ptr, DB::QueryFlags) @ 0x0000000013da037d 5. /build/src/Interpreters/InterpreterDropQuery.cpp:226: DB::InterpreterDropQuery::executeToTableImpl(std::shared_ptr const&, DB::ASTDropQuery&, std::shared_ptr&, StrongTypedef, DB::UUIDTag>&) @ 0x0000000014914ed7 6. /build/src/Interpreters/InterpreterDropQuery.cpp:118: DB::InterpreterDropQuery::executeToTable(DB::ASTDropQuery&) @ 0x00000000149137b4 7. /build/src/Interpreters/InterpreterDropQuery.cpp:91: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000014912f07 8. /build/src/Interpreters/InterpreterDropQuery.cpp:72: DB::InterpreterDropQuery::execute() @ 0x0000000014912b65 9. /build/src/Interpreters/InterpreterDropQuery.cpp:579: DB::InterpreterDropQuery::executeDropQuery(DB::ASTDropQuery::Kind, std::shared_ptr, std::shared_ptr, DB::StorageID const&, bool, bool, bool) @ 0x0000000014918aa0 10. /build/src/Storages/StorageMaterializedView.cpp:481: DB::StorageMaterializedView::truncate(std::shared_ptr const&, std::shared_ptr const&, std::shared_ptr, DB::TableExclusiveLockHolder&) @ 0x0000000015e1fd56 11. /build/src/Interpreters/InterpreterDropQuery.cpp:282: DB::InterpreterDropQuery::executeToTableImpl(std::shared_ptr const&, DB::ASTDropQuery&, std::shared_ptr&, StrongTypedef, DB::UUIDTag>&) @ 0x0000000014915304 12. /build/src/Interpreters/InterpreterDropQuery.cpp:461: DB::InterpreterDropQuery::executeToDatabaseImpl(DB::ASTDropQuery const&, std::shared_ptr&, std::vector, DB::UUIDTag>, std::allocator, DB::UUIDTag>>>&) @ 0x0000000014917707 13. /build/src/Interpreters/InterpreterDropQuery.cpp:363: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x0000000014913988 14. /build/src/Interpreters/InterpreterDropQuery.cpp:99: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000014913142 15. /build/src/Interpreters/InterpreterDropQuery.cpp:72: DB::InterpreterDropQuery::execute() @ 0x0000000014912b65 16. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88dc9 17. /build/src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x0000000014c8ca7b 18. /build/src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000001686da12 19. /build/src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x0000000016870807 20. /build/src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x0000000016907e99 21. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 22. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 23. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 24. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 25. ? @ 0x00007fbc6213eac3 26. ? @ 0x00007fbc621d0850 2025.07.28 11:50:56.657632 [ 6322 ] {2bd4a807-f9a9-4d49-ba65-e302eae3c267} DynamicQueryHandler: 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. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000000a074fcb 4. /build/src/Databases/DatabaseReplicated.cpp:1128: DB::DatabaseReplicated::tryEnqueueReplicatedDDL(std::shared_ptr const&, std::shared_ptr, DB::QueryFlags) @ 0x0000000013da037d 5. /build/src/Interpreters/InterpreterDropQuery.cpp:226: DB::InterpreterDropQuery::executeToTableImpl(std::shared_ptr const&, DB::ASTDropQuery&, std::shared_ptr&, StrongTypedef, DB::UUIDTag>&) @ 0x0000000014914ed7 6. /build/src/Interpreters/InterpreterDropQuery.cpp:118: DB::InterpreterDropQuery::executeToTable(DB::ASTDropQuery&) @ 0x00000000149137b4 7. /build/src/Interpreters/InterpreterDropQuery.cpp:91: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000014912f07 8. /build/src/Interpreters/InterpreterDropQuery.cpp:72: DB::InterpreterDropQuery::execute() @ 0x0000000014912b65 9. /build/src/Interpreters/InterpreterDropQuery.cpp:579: DB::InterpreterDropQuery::executeDropQuery(DB::ASTDropQuery::Kind, std::shared_ptr, std::shared_ptr, DB::StorageID const&, bool, bool, bool) @ 0x0000000014918aa0 10. /build/src/Storages/StorageMaterializedView.cpp:481: DB::StorageMaterializedView::truncate(std::shared_ptr const&, std::shared_ptr const&, std::shared_ptr, DB::TableExclusiveLockHolder&) @ 0x0000000015e1fd56 11. /build/src/Interpreters/InterpreterDropQuery.cpp:282: DB::InterpreterDropQuery::executeToTableImpl(std::shared_ptr const&, DB::ASTDropQuery&, std::shared_ptr&, StrongTypedef, DB::UUIDTag>&) @ 0x0000000014915304 12. /build/src/Interpreters/InterpreterDropQuery.cpp:461: DB::InterpreterDropQuery::executeToDatabaseImpl(DB::ASTDropQuery const&, std::shared_ptr&, std::vector, DB::UUIDTag>, std::allocator, DB::UUIDTag>>>&) @ 0x0000000014917707 13. /build/src/Interpreters/InterpreterDropQuery.cpp:363: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x0000000014913988 14. /build/src/Interpreters/InterpreterDropQuery.cpp:99: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000014913142 15. /build/src/Interpreters/InterpreterDropQuery.cpp:72: DB::InterpreterDropQuery::execute() @ 0x0000000014912b65 16. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88dc9 17. /build/src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x0000000014c8ca7b 18. /build/src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000001686da12 19. /build/src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x0000000016870807 20. /build/src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x0000000016907e99 21. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 22. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 23. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 24. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 25. ? @ 0x00007fbc6213eac3 26. ? @ 0x00007fbc621d0850 (version 25.3.6.10636.altinitytest (altinity build)) 2025.07.28 11:50:56.963776 [ 4446 ] {36b2ab07-40bb-414d-b24a-910008b3e6a8} executeQuery: Code: 253. DB::Exception: Replica r1 of shard s1 of replicated database at /test/db/test_8 already exists. Replica host ID: '146b4357c08d:9000:ee38db95-0be7-448e-98e5-40a61c7cf34b', current host ID: '146b4357c08d:9000:b7ae3430-5483-45c3-ad5f-805ab776db75'. (REPLICA_ALREADY_EXISTS) (version 25.3.6.10636.altinitytest (altinity build)) (from [::1]:50116) (comment: 02809_storage_set_analysis_bug.sql) (in query: CREATE DATABASE IF NOT EXISTS test_se3te03n ENGINE=Replicated('/test/db/test_8', 's1', 'r1') ), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.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&) @ 0x0000000013db5399 4. /build/src/Databases/DatabaseReplicated.cpp:494: DB::DatabaseReplicated::tryConnectToZooKeeperAndInitDatabase(DB::LoadingStrictnessLevel) @ 0x0000000013d91155 5. /build/src/Databases/DatabaseReplicated.cpp:735: DB::DatabaseReplicated::beforeLoadingMetadata(std::shared_ptr, DB::LoadingStrictnessLevel) @ 0x0000000013d954d4 6. /build/src/Databases/TablesLoader.cpp:57: DB::TablesLoader::loadTablesAsync(std::unordered_set, std::hash>, std::equal_to>, std::allocator>>) @ 0x000000001490e734 7. /build/src/Interpreters/InterpreterCreateQuery.cpp:383: DB::InterpreterCreateQuery::createDatabase(DB::ASTCreateQuery&) @ 0x00000000148e8e14 8. /build/src/Interpreters/InterpreterCreateQuery.cpp:2351: DB::InterpreterCreateQuery::execute() @ 0x0000000014905a3a 9. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88dc9 10. /build/src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x0000000014c8ca7b 11. /build/src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000001686da12 12. /build/src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x0000000016870807 13. /build/src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x0000000016907e99 14. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 15. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 16. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 17. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 18. ? @ 0x00007fbc6213eac3 19. ? @ 0x00007fbc621d0850 2025.07.28 11:50:56.976996 [ 4446 ] {36b2ab07-40bb-414d-b24a-910008b3e6a8} DynamicQueryHandler: Code: 253. DB::Exception: Replica r1 of shard s1 of replicated database at /test/db/test_8 already exists. Replica host ID: '146b4357c08d:9000:ee38db95-0be7-448e-98e5-40a61c7cf34b', current host ID: '146b4357c08d:9000:b7ae3430-5483-45c3-ad5f-805ab776db75'. (REPLICA_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.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&) @ 0x0000000013db5399 4. /build/src/Databases/DatabaseReplicated.cpp:494: DB::DatabaseReplicated::tryConnectToZooKeeperAndInitDatabase(DB::LoadingStrictnessLevel) @ 0x0000000013d91155 5. /build/src/Databases/DatabaseReplicated.cpp:735: DB::DatabaseReplicated::beforeLoadingMetadata(std::shared_ptr, DB::LoadingStrictnessLevel) @ 0x0000000013d954d4 6. /build/src/Databases/TablesLoader.cpp:57: DB::TablesLoader::loadTablesAsync(std::unordered_set, std::hash>, std::equal_to>, std::allocator>>) @ 0x000000001490e734 7. /build/src/Interpreters/InterpreterCreateQuery.cpp:383: DB::InterpreterCreateQuery::createDatabase(DB::ASTCreateQuery&) @ 0x00000000148e8e14 8. /build/src/Interpreters/InterpreterCreateQuery.cpp:2351: DB::InterpreterCreateQuery::execute() @ 0x0000000014905a3a 9. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88dc9 10. /build/src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x0000000014c8ca7b 11. /build/src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000001686da12 12. /build/src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x0000000016870807 13. /build/src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x0000000016907e99 14. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 15. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 16. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 17. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 18. ? @ 0x00007fbc6213eac3 19. ? @ 0x00007fbc621d0850 (version 25.3.6.10636.altinitytest (altinity build)) 2025.07.28 11:50:57.170844 [ 5029 ] {2010d4fd-b105-42a0-b709-b5507a5a3b0e} executeQuery: Code: 253. DB::Exception: Replica r1 of shard s1 of replicated database at /test/db/test_8 already exists. Replica host ID: '146b4357c08d:9000:ee38db95-0be7-448e-98e5-40a61c7cf34b', current host ID: '146b4357c08d:9000:f8f0452a-d739-4075-9cb7-a27f4050bcf8'. (REPLICA_ALREADY_EXISTS) (version 25.3.6.10636.altinitytest (altinity build)) (from [::1]:50130) (comment: 01671_merge_join_and_constants.sql) (in query: CREATE DATABASE IF NOT EXISTS test_rxv8nodc ENGINE=Replicated('/test/db/test_8', 's1', 'r1') ), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.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&) @ 0x0000000013db5399 4. /build/src/Databases/DatabaseReplicated.cpp:494: DB::DatabaseReplicated::tryConnectToZooKeeperAndInitDatabase(DB::LoadingStrictnessLevel) @ 0x0000000013d91155 5. /build/src/Databases/DatabaseReplicated.cpp:735: DB::DatabaseReplicated::beforeLoadingMetadata(std::shared_ptr, DB::LoadingStrictnessLevel) @ 0x0000000013d954d4 6. /build/src/Databases/TablesLoader.cpp:57: DB::TablesLoader::loadTablesAsync(std::unordered_set, std::hash>, std::equal_to>, std::allocator>>) @ 0x000000001490e734 7. /build/src/Interpreters/InterpreterCreateQuery.cpp:383: DB::InterpreterCreateQuery::createDatabase(DB::ASTCreateQuery&) @ 0x00000000148e8e14 8. /build/src/Interpreters/InterpreterCreateQuery.cpp:2351: DB::InterpreterCreateQuery::execute() @ 0x0000000014905a3a 9. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88dc9 10. /build/src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x0000000014c8ca7b 11. /build/src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000001686da12 12. /build/src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x0000000016870807 13. /build/src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x0000000016907e99 14. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 15. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 16. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 17. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 18. ? @ 0x00007fbc6213eac3 19. ? @ 0x00007fbc621d0850 2025.07.28 11:50:57.174521 [ 5029 ] {2010d4fd-b105-42a0-b709-b5507a5a3b0e} DynamicQueryHandler: Code: 253. DB::Exception: Replica r1 of shard s1 of replicated database at /test/db/test_8 already exists. Replica host ID: '146b4357c08d:9000:ee38db95-0be7-448e-98e5-40a61c7cf34b', current host ID: '146b4357c08d:9000:f8f0452a-d739-4075-9cb7-a27f4050bcf8'. (REPLICA_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.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&) @ 0x0000000013db5399 4. /build/src/Databases/DatabaseReplicated.cpp:494: DB::DatabaseReplicated::tryConnectToZooKeeperAndInitDatabase(DB::LoadingStrictnessLevel) @ 0x0000000013d91155 5. /build/src/Databases/DatabaseReplicated.cpp:735: DB::DatabaseReplicated::beforeLoadingMetadata(std::shared_ptr, DB::LoadingStrictnessLevel) @ 0x0000000013d954d4 6. /build/src/Databases/TablesLoader.cpp:57: DB::TablesLoader::loadTablesAsync(std::unordered_set, std::hash>, std::equal_to>, std::allocator>>) @ 0x000000001490e734 7. /build/src/Interpreters/InterpreterCreateQuery.cpp:383: DB::InterpreterCreateQuery::createDatabase(DB::ASTCreateQuery&) @ 0x00000000148e8e14 8. /build/src/Interpreters/InterpreterCreateQuery.cpp:2351: DB::InterpreterCreateQuery::execute() @ 0x0000000014905a3a 9. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88dc9 10. /build/src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x0000000014c8ca7b 11. /build/src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000001686da12 12. /build/src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x0000000016870807 13. /build/src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x0000000016907e99 14. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 15. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 16. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 17. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 18. ? @ 0x00007fbc6213eac3 19. ? @ 0x00007fbc621d0850 (version 25.3.6.10636.altinitytest (altinity build)) 2025.07.28 11:50:57.261524 [ 5327 ] {d10876f0-1e8b-4ed9-8c4a-a173a2dda3ac} executeQuery: Code: 253. DB::Exception: Replica r1 of shard s1 of replicated database at /test/db/test_8 already exists. Replica host ID: '146b4357c08d:9000:ee38db95-0be7-448e-98e5-40a61c7cf34b', current host ID: '146b4357c08d:9000:5b5b7686-c5b0-43ab-88b5-a4dda5fdf1f6'. (REPLICA_ALREADY_EXISTS) (version 25.3.6.10636.altinitytest (altinity build)) (from [::1]:50144) (comment: 00159_whitespace_in_columns_list.sql) (in query: CREATE DATABASE IF NOT EXISTS test_0t9xh9j6 ENGINE=Replicated('/test/db/test_8', 's1', 'r1') ), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.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&) @ 0x0000000013db5399 4. /build/src/Databases/DatabaseReplicated.cpp:494: DB::DatabaseReplicated::tryConnectToZooKeeperAndInitDatabase(DB::LoadingStrictnessLevel) @ 0x0000000013d91155 5. /build/src/Databases/DatabaseReplicated.cpp:735: DB::DatabaseReplicated::beforeLoadingMetadata(std::shared_ptr, DB::LoadingStrictnessLevel) @ 0x0000000013d954d4 6. /build/src/Databases/TablesLoader.cpp:57: DB::TablesLoader::loadTablesAsync(std::unordered_set, std::hash>, std::equal_to>, std::allocator>>) @ 0x000000001490e734 7. /build/src/Interpreters/InterpreterCreateQuery.cpp:383: DB::InterpreterCreateQuery::createDatabase(DB::ASTCreateQuery&) @ 0x00000000148e8e14 8. /build/src/Interpreters/InterpreterCreateQuery.cpp:2351: DB::InterpreterCreateQuery::execute() @ 0x0000000014905a3a 9. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88dc9 10. /build/src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x0000000014c8ca7b 11. /build/src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000001686da12 12. /build/src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x0000000016870807 13. /build/src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x0000000016907e99 14. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 15. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 16. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 17. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 18. ? @ 0x00007fbc6213eac3 19. ? @ 0x00007fbc621d0850 2025.07.28 11:50:57.282284 [ 5327 ] {d10876f0-1e8b-4ed9-8c4a-a173a2dda3ac} DynamicQueryHandler: Code: 253. DB::Exception: Replica r1 of shard s1 of replicated database at /test/db/test_8 already exists. Replica host ID: '146b4357c08d:9000:ee38db95-0be7-448e-98e5-40a61c7cf34b', current host ID: '146b4357c08d:9000:5b5b7686-c5b0-43ab-88b5-a4dda5fdf1f6'. (REPLICA_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.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&) @ 0x0000000013db5399 4. /build/src/Databases/DatabaseReplicated.cpp:494: DB::DatabaseReplicated::tryConnectToZooKeeperAndInitDatabase(DB::LoadingStrictnessLevel) @ 0x0000000013d91155 5. /build/src/Databases/DatabaseReplicated.cpp:735: DB::DatabaseReplicated::beforeLoadingMetadata(std::shared_ptr, DB::LoadingStrictnessLevel) @ 0x0000000013d954d4 6. /build/src/Databases/TablesLoader.cpp:57: DB::TablesLoader::loadTablesAsync(std::unordered_set, std::hash>, std::equal_to>, std::allocator>>) @ 0x000000001490e734 7. /build/src/Interpreters/InterpreterCreateQuery.cpp:383: DB::InterpreterCreateQuery::createDatabase(DB::ASTCreateQuery&) @ 0x00000000148e8e14 8. /build/src/Interpreters/InterpreterCreateQuery.cpp:2351: DB::InterpreterCreateQuery::execute() @ 0x0000000014905a3a 9. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88dc9 10. /build/src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x0000000014c8ca7b 11. /build/src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000001686da12 12. /build/src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x0000000016870807 13. /build/src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x0000000016907e99 14. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 15. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 16. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 17. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 18. ? @ 0x00007fbc6213eac3 19. ? @ 0x00007fbc621d0850 (version 25.3.6.10636.altinitytest (altinity build)) 2025.07.28 11:50:57.468112 [ 5951 ] {517371ab-ec9a-476d-983a-611fd2737322} executeQuery: Code: 253. DB::Exception: Replica r1 of shard s1 of replicated database at /test/db/test_8 already exists. Replica host ID: '146b4357c08d:9000:ee38db95-0be7-448e-98e5-40a61c7cf34b', current host ID: '146b4357c08d:9000:c172fdf2-6720-4005-9cac-046e2f3a037b'. (REPLICA_ALREADY_EXISTS) (version 25.3.6.10636.altinitytest (altinity build)) (from [::1]:50150) (comment: 02478_window_frame_type_groups.sql) (in query: CREATE DATABASE IF NOT EXISTS test_pethnlg3 ENGINE=Replicated('/test/db/test_8', 's1', 'r1') ), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.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&) @ 0x0000000013db5399 4. /build/src/Databases/DatabaseReplicated.cpp:494: DB::DatabaseReplicated::tryConnectToZooKeeperAndInitDatabase(DB::LoadingStrictnessLevel) @ 0x0000000013d91155 5. /build/src/Databases/DatabaseReplicated.cpp:735: DB::DatabaseReplicated::beforeLoadingMetadata(std::shared_ptr, DB::LoadingStrictnessLevel) @ 0x0000000013d954d4 6. /build/src/Databases/TablesLoader.cpp:57: DB::TablesLoader::loadTablesAsync(std::unordered_set, std::hash>, std::equal_to>, std::allocator>>) @ 0x000000001490e734 7. /build/src/Interpreters/InterpreterCreateQuery.cpp:383: DB::InterpreterCreateQuery::createDatabase(DB::ASTCreateQuery&) @ 0x00000000148e8e14 8. /build/src/Interpreters/InterpreterCreateQuery.cpp:2351: DB::InterpreterCreateQuery::execute() @ 0x0000000014905a3a 9. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88dc9 10. /build/src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x0000000014c8ca7b 11. /build/src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000001686da12 12. /build/src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x0000000016870807 13. /build/src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x0000000016907e99 14. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 15. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 16. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 17. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 18. ? @ 0x00007fbc6213eac3 19. ? @ 0x00007fbc621d0850 2025.07.28 11:50:57.476656 [ 5951 ] {517371ab-ec9a-476d-983a-611fd2737322} DynamicQueryHandler: Code: 253. DB::Exception: Replica r1 of shard s1 of replicated database at /test/db/test_8 already exists. Replica host ID: '146b4357c08d:9000:ee38db95-0be7-448e-98e5-40a61c7cf34b', current host ID: '146b4357c08d:9000:c172fdf2-6720-4005-9cac-046e2f3a037b'. (REPLICA_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.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&) @ 0x0000000013db5399 4. /build/src/Databases/DatabaseReplicated.cpp:494: DB::DatabaseReplicated::tryConnectToZooKeeperAndInitDatabase(DB::LoadingStrictnessLevel) @ 0x0000000013d91155 5. /build/src/Databases/DatabaseReplicated.cpp:735: DB::DatabaseReplicated::beforeLoadingMetadata(std::shared_ptr, DB::LoadingStrictnessLevel) @ 0x0000000013d954d4 6. /build/src/Databases/TablesLoader.cpp:57: DB::TablesLoader::loadTablesAsync(std::unordered_set, std::hash>, std::equal_to>, std::allocator>>) @ 0x000000001490e734 7. /build/src/Interpreters/InterpreterCreateQuery.cpp:383: DB::InterpreterCreateQuery::createDatabase(DB::ASTCreateQuery&) @ 0x00000000148e8e14 8. /build/src/Interpreters/InterpreterCreateQuery.cpp:2351: DB::InterpreterCreateQuery::execute() @ 0x0000000014905a3a 9. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88dc9 10. /build/src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x0000000014c8ca7b 11. /build/src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000001686da12 12. /build/src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x0000000016870807 13. /build/src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x0000000016907e99 14. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 15. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 16. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 17. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 18. ? @ 0x00007fbc6213eac3 19. ? @ 0x00007fbc621d0850 (version 25.3.6.10636.altinitytest (altinity build)) 2025.07.28 11:50:57.555593 [ 12454 ] {be2847bc-f84c-4cd7-a531-11c14c87a061} executeQuery: Code: 253. DB::Exception: Replica r1 of shard s1 of replicated database at /test/db/test_8 already exists. Replica host ID: '146b4357c08d:9000:ee38db95-0be7-448e-98e5-40a61c7cf34b', current host ID: '146b4357c08d:9000:4ce10978-9caf-45ff-b6a1-674ac4c9560b'. (REPLICA_ALREADY_EXISTS) (version 25.3.6.10636.altinitytest (altinity build)) (from [::1]:50162) (comment: 00030_alter_table.sql) (in query: CREATE DATABASE IF NOT EXISTS test_dabfqxrf ENGINE=Replicated('/test/db/test_8', 's1', 'r1') ), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.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&) @ 0x0000000013db5399 4. /build/src/Databases/DatabaseReplicated.cpp:494: DB::DatabaseReplicated::tryConnectToZooKeeperAndInitDatabase(DB::LoadingStrictnessLevel) @ 0x0000000013d91155 5. /build/src/Databases/DatabaseReplicated.cpp:735: DB::DatabaseReplicated::beforeLoadingMetadata(std::shared_ptr, DB::LoadingStrictnessLevel) @ 0x0000000013d954d4 6. /build/src/Databases/TablesLoader.cpp:57: DB::TablesLoader::loadTablesAsync(std::unordered_set, std::hash>, std::equal_to>, std::allocator>>) @ 0x000000001490e734 7. /build/src/Interpreters/InterpreterCreateQuery.cpp:383: DB::InterpreterCreateQuery::createDatabase(DB::ASTCreateQuery&) @ 0x00000000148e8e14 8. /build/src/Interpreters/InterpreterCreateQuery.cpp:2351: DB::InterpreterCreateQuery::execute() @ 0x0000000014905a3a 9. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88dc9 10. /build/src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x0000000014c8ca7b 11. /build/src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000001686da12 12. /build/src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x0000000016870807 13. /build/src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x0000000016907e99 14. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 15. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 16. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 17. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 18. ? @ 0x00007fbc6213eac3 19. ? @ 0x00007fbc621d0850 2025.07.28 11:50:57.558376 [ 12454 ] {be2847bc-f84c-4cd7-a531-11c14c87a061} DynamicQueryHandler: Code: 253. DB::Exception: Replica r1 of shard s1 of replicated database at /test/db/test_8 already exists. Replica host ID: '146b4357c08d:9000:ee38db95-0be7-448e-98e5-40a61c7cf34b', current host ID: '146b4357c08d:9000:4ce10978-9caf-45ff-b6a1-674ac4c9560b'. (REPLICA_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.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&) @ 0x0000000013db5399 4. /build/src/Databases/DatabaseReplicated.cpp:494: DB::DatabaseReplicated::tryConnectToZooKeeperAndInitDatabase(DB::LoadingStrictnessLevel) @ 0x0000000013d91155 5. /build/src/Databases/DatabaseReplicated.cpp:735: DB::DatabaseReplicated::beforeLoadingMetadata(std::shared_ptr, DB::LoadingStrictnessLevel) @ 0x0000000013d954d4 6. /build/src/Databases/TablesLoader.cpp:57: DB::TablesLoader::loadTablesAsync(std::unordered_set, std::hash>, std::equal_to>, std::allocator>>) @ 0x000000001490e734 7. /build/src/Interpreters/InterpreterCreateQuery.cpp:383: DB::InterpreterCreateQuery::createDatabase(DB::ASTCreateQuery&) @ 0x00000000148e8e14 8. /build/src/Interpreters/InterpreterCreateQuery.cpp:2351: DB::InterpreterCreateQuery::execute() @ 0x0000000014905a3a 9. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88dc9 10. /build/src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x0000000014c8ca7b 11. /build/src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000001686da12 12. /build/src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x0000000016870807 13. /build/src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x0000000016907e99 14. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 15. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 16. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 17. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 18. ? @ 0x00007fbc6213eac3 19. ? @ 0x00007fbc621d0850 (version 25.3.6.10636.altinitytest (altinity build)) 2025.07.28 11:50:57.740974 [ 4454 ] {653147b3-139a-421a-807a-f31349bf65db} executeQuery: Code: 253. DB::Exception: Replica r1 of shard s1 of replicated database at /test/db/test_8 already exists. Replica host ID: '146b4357c08d:9000:ee38db95-0be7-448e-98e5-40a61c7cf34b', current host ID: '146b4357c08d:9000:1bd6f2fd-4a80-4852-8b41-9c2e1a45a75f'. (REPLICA_ALREADY_EXISTS) (version 25.3.6.10636.altinitytest (altinity build)) (from [::1]:50164) (comment: 03228_clickhouse_local_copy_argument.sh) (in query: CREATE DATABASE IF NOT EXISTS test_8hccibfd ENGINE=Replicated('/test/db/test_8', 's1', 'r1') ), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.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&) @ 0x0000000013db5399 4. /build/src/Databases/DatabaseReplicated.cpp:494: DB::DatabaseReplicated::tryConnectToZooKeeperAndInitDatabase(DB::LoadingStrictnessLevel) @ 0x0000000013d91155 5. /build/src/Databases/DatabaseReplicated.cpp:735: DB::DatabaseReplicated::beforeLoadingMetadata(std::shared_ptr, DB::LoadingStrictnessLevel) @ 0x0000000013d954d4 6. /build/src/Databases/TablesLoader.cpp:57: DB::TablesLoader::loadTablesAsync(std::unordered_set, std::hash>, std::equal_to>, std::allocator>>) @ 0x000000001490e734 7. /build/src/Interpreters/InterpreterCreateQuery.cpp:383: DB::InterpreterCreateQuery::createDatabase(DB::ASTCreateQuery&) @ 0x00000000148e8e14 8. /build/src/Interpreters/InterpreterCreateQuery.cpp:2351: DB::InterpreterCreateQuery::execute() @ 0x0000000014905a3a 9. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88dc9 10. /build/src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x0000000014c8ca7b 11. /build/src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000001686da12 12. /build/src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x0000000016870807 13. /build/src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x0000000016907e99 14. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 15. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 16. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 17. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 18. ? @ 0x00007fbc6213eac3 19. ? @ 0x00007fbc621d0850 2025.07.28 11:50:57.743742 [ 4454 ] {653147b3-139a-421a-807a-f31349bf65db} DynamicQueryHandler: Code: 253. DB::Exception: Replica r1 of shard s1 of replicated database at /test/db/test_8 already exists. Replica host ID: '146b4357c08d:9000:ee38db95-0be7-448e-98e5-40a61c7cf34b', current host ID: '146b4357c08d:9000:1bd6f2fd-4a80-4852-8b41-9c2e1a45a75f'. (REPLICA_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.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&) @ 0x0000000013db5399 4. /build/src/Databases/DatabaseReplicated.cpp:494: DB::DatabaseReplicated::tryConnectToZooKeeperAndInitDatabase(DB::LoadingStrictnessLevel) @ 0x0000000013d91155 5. /build/src/Databases/DatabaseReplicated.cpp:735: DB::DatabaseReplicated::beforeLoadingMetadata(std::shared_ptr, DB::LoadingStrictnessLevel) @ 0x0000000013d954d4 6. /build/src/Databases/TablesLoader.cpp:57: DB::TablesLoader::loadTablesAsync(std::unordered_set, std::hash>, std::equal_to>, std::allocator>>) @ 0x000000001490e734 7. /build/src/Interpreters/InterpreterCreateQuery.cpp:383: DB::InterpreterCreateQuery::createDatabase(DB::ASTCreateQuery&) @ 0x00000000148e8e14 8. /build/src/Interpreters/InterpreterCreateQuery.cpp:2351: DB::InterpreterCreateQuery::execute() @ 0x0000000014905a3a 9. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88dc9 10. /build/src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x0000000014c8ca7b 11. /build/src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000001686da12 12. /build/src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x0000000016870807 13. /build/src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x0000000016907e99 14. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 15. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 16. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 17. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 18. ? @ 0x00007fbc6213eac3 19. ? @ 0x00007fbc621d0850 (version 25.3.6.10636.altinitytest (altinity build)) 2025.07.28 11:50:57.874511 [ 6322 ] {f4a6580c-b553-477d-9fe2-1d1daba9bfc0} executeQuery: Code: 253. DB::Exception: Replica r1 of shard s1 of replicated database at /test/db/test_8 already exists. Replica host ID: '146b4357c08d:9000:ee38db95-0be7-448e-98e5-40a61c7cf34b', current host ID: '146b4357c08d:9000:e18b8b25-e21a-4baf-8b4b-7a77ab0a813f'. (REPLICA_ALREADY_EXISTS) (version 25.3.6.10636.altinitytest (altinity build)) (from [::1]:50182) (comment: 01293_show_settings.sql) (in query: CREATE DATABASE IF NOT EXISTS test_89gfr4bq ENGINE=Replicated('/test/db/test_8', 's1', 'r1') ), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.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&) @ 0x0000000013db5399 4. /build/src/Databases/DatabaseReplicated.cpp:494: DB::DatabaseReplicated::tryConnectToZooKeeperAndInitDatabase(DB::LoadingStrictnessLevel) @ 0x0000000013d91155 5. /build/src/Databases/DatabaseReplicated.cpp:735: DB::DatabaseReplicated::beforeLoadingMetadata(std::shared_ptr, DB::LoadingStrictnessLevel) @ 0x0000000013d954d4 6. /build/src/Databases/TablesLoader.cpp:57: DB::TablesLoader::loadTablesAsync(std::unordered_set, std::hash>, std::equal_to>, std::allocator>>) @ 0x000000001490e734 7. /build/src/Interpreters/InterpreterCreateQuery.cpp:383: DB::InterpreterCreateQuery::createDatabase(DB::ASTCreateQuery&) @ 0x00000000148e8e14 8. /build/src/Interpreters/InterpreterCreateQuery.cpp:2351: DB::InterpreterCreateQuery::execute() @ 0x0000000014905a3a 9. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88dc9 10. /build/src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x0000000014c8ca7b 11. /build/src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000001686da12 12. /build/src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x0000000016870807 13. /build/src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x0000000016907e99 14. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 15. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 16. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 17. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 18. ? @ 0x00007fbc6213eac3 19. ? @ 0x00007fbc621d0850 2025.07.28 11:50:57.879765 [ 6322 ] {f4a6580c-b553-477d-9fe2-1d1daba9bfc0} DynamicQueryHandler: Code: 253. DB::Exception: Replica r1 of shard s1 of replicated database at /test/db/test_8 already exists. Replica host ID: '146b4357c08d:9000:ee38db95-0be7-448e-98e5-40a61c7cf34b', current host ID: '146b4357c08d:9000:e18b8b25-e21a-4baf-8b4b-7a77ab0a813f'. (REPLICA_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.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&) @ 0x0000000013db5399 4. /build/src/Databases/DatabaseReplicated.cpp:494: DB::DatabaseReplicated::tryConnectToZooKeeperAndInitDatabase(DB::LoadingStrictnessLevel) @ 0x0000000013d91155 5. /build/src/Databases/DatabaseReplicated.cpp:735: DB::DatabaseReplicated::beforeLoadingMetadata(std::shared_ptr, DB::LoadingStrictnessLevel) @ 0x0000000013d954d4 6. /build/src/Databases/TablesLoader.cpp:57: DB::TablesLoader::loadTablesAsync(std::unordered_set, std::hash>, std::equal_to>, std::allocator>>) @ 0x000000001490e734 7. /build/src/Interpreters/InterpreterCreateQuery.cpp:383: DB::InterpreterCreateQuery::createDatabase(DB::ASTCreateQuery&) @ 0x00000000148e8e14 8. /build/src/Interpreters/InterpreterCreateQuery.cpp:2351: DB::InterpreterCreateQuery::execute() @ 0x0000000014905a3a 9. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88dc9 10. /build/src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x0000000014c8ca7b 11. /build/src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000001686da12 12. /build/src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x0000000016870807 13. /build/src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x0000000016907e99 14. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 15. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 16. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 17. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 18. ? @ 0x00007fbc6213eac3 19. ? @ 0x00007fbc621d0850 (version 25.3.6.10636.altinitytest (altinity build)) 2025.07.28 11:50:57.961538 [ 12807 ] {e4850477-debb-4f0e-a9b3-1c31a7574995} executeQuery: Code: 253. DB::Exception: Replica r1 of shard s1 of replicated database at /test/db/test_8 already exists. Replica host ID: '146b4357c08d:9000:ee38db95-0be7-448e-98e5-40a61c7cf34b', current host ID: '146b4357c08d:9000:ea959a2d-f85a-4bc5-b32d-c19b5b7ef2ec'. (REPLICA_ALREADY_EXISTS) (version 25.3.6.10636.altinitytest (altinity build)) (from [::1]:50202) (comment: 01411_xor_itai_shirav.sql) (in query: CREATE DATABASE IF NOT EXISTS test_i60barmd ENGINE=Replicated('/test/db/test_8', 's1', 'r1') ), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.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&) @ 0x0000000013db5399 4. /build/src/Databases/DatabaseReplicated.cpp:494: DB::DatabaseReplicated::tryConnectToZooKeeperAndInitDatabase(DB::LoadingStrictnessLevel) @ 0x0000000013d91155 5. /build/src/Databases/DatabaseReplicated.cpp:735: DB::DatabaseReplicated::beforeLoadingMetadata(std::shared_ptr, DB::LoadingStrictnessLevel) @ 0x0000000013d954d4 6. /build/src/Databases/TablesLoader.cpp:57: DB::TablesLoader::loadTablesAsync(std::unordered_set, std::hash>, std::equal_to>, std::allocator>>) @ 0x000000001490e734 7. /build/src/Interpreters/InterpreterCreateQuery.cpp:383: DB::InterpreterCreateQuery::createDatabase(DB::ASTCreateQuery&) @ 0x00000000148e8e14 8. /build/src/Interpreters/InterpreterCreateQuery.cpp:2351: DB::InterpreterCreateQuery::execute() @ 0x0000000014905a3a 9. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88dc9 10. /build/src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x0000000014c8ca7b 11. /build/src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000001686da12 12. /build/src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x0000000016870807 13. /build/src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x0000000016907e99 14. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 15. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 16. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 17. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 18. ? @ 0x00007fbc6213eac3 19. ? @ 0x00007fbc621d0850 2025.07.28 11:50:57.984616 [ 12807 ] {e4850477-debb-4f0e-a9b3-1c31a7574995} DynamicQueryHandler: Code: 253. DB::Exception: Replica r1 of shard s1 of replicated database at /test/db/test_8 already exists. Replica host ID: '146b4357c08d:9000:ee38db95-0be7-448e-98e5-40a61c7cf34b', current host ID: '146b4357c08d:9000:ea959a2d-f85a-4bc5-b32d-c19b5b7ef2ec'. (REPLICA_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.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&) @ 0x0000000013db5399 4. /build/src/Databases/DatabaseReplicated.cpp:494: DB::DatabaseReplicated::tryConnectToZooKeeperAndInitDatabase(DB::LoadingStrictnessLevel) @ 0x0000000013d91155 5. /build/src/Databases/DatabaseReplicated.cpp:735: DB::DatabaseReplicated::beforeLoadingMetadata(std::shared_ptr, DB::LoadingStrictnessLevel) @ 0x0000000013d954d4 6. /build/src/Databases/TablesLoader.cpp:57: DB::TablesLoader::loadTablesAsync(std::unordered_set, std::hash>, std::equal_to>, std::allocator>>) @ 0x000000001490e734 7. /build/src/Interpreters/InterpreterCreateQuery.cpp:383: DB::InterpreterCreateQuery::createDatabase(DB::ASTCreateQuery&) @ 0x00000000148e8e14 8. /build/src/Interpreters/InterpreterCreateQuery.cpp:2351: DB::InterpreterCreateQuery::execute() @ 0x0000000014905a3a 9. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88dc9 10. /build/src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x0000000014c8ca7b 11. /build/src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000001686da12 12. /build/src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x0000000016870807 13. /build/src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x0000000016907e99 14. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 15. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 16. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 17. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 18. ? @ 0x00007fbc6213eac3 19. ? @ 0x00007fbc621d0850 (version 25.3.6.10636.altinitytest (altinity build)) 2025.07.28 11:50:58.073845 [ 4581 ] {e4591a05-f997-4935-a470-3c38a58f62cf} executeQuery: Code: 253. DB::Exception: Replica r1 of shard s1 of replicated database at /test/db/test_8 already exists. Replica host ID: '146b4357c08d:9000:ee38db95-0be7-448e-98e5-40a61c7cf34b', current host ID: '146b4357c08d:9000:d8be73e5-56ff-4b08-b137-186281148d58'. (REPLICA_ALREADY_EXISTS) (version 25.3.6.10636.altinitytest (altinity build)) (from [::1]:50212) (comment: 02870_move_partition_to_volume_io_throttling.sql) (in query: CREATE DATABASE IF NOT EXISTS test_39k8y2ln ENGINE=Replicated('/test/db/test_8', 's1', 'r1') ), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.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&) @ 0x0000000013db5399 4. /build/src/Databases/DatabaseReplicated.cpp:494: DB::DatabaseReplicated::tryConnectToZooKeeperAndInitDatabase(DB::LoadingStrictnessLevel) @ 0x0000000013d91155 5. /build/src/Databases/DatabaseReplicated.cpp:735: DB::DatabaseReplicated::beforeLoadingMetadata(std::shared_ptr, DB::LoadingStrictnessLevel) @ 0x0000000013d954d4 6. /build/src/Databases/TablesLoader.cpp:57: DB::TablesLoader::loadTablesAsync(std::unordered_set, std::hash>, std::equal_to>, std::allocator>>) @ 0x000000001490e734 7. /build/src/Interpreters/InterpreterCreateQuery.cpp:383: DB::InterpreterCreateQuery::createDatabase(DB::ASTCreateQuery&) @ 0x00000000148e8e14 8. /build/src/Interpreters/InterpreterCreateQuery.cpp:2351: DB::InterpreterCreateQuery::execute() @ 0x0000000014905a3a 9. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88dc9 10. /build/src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x0000000014c8ca7b 11. /build/src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000001686da12 12. /build/src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x0000000016870807 13. /build/src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x0000000016907e99 14. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 15. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 16. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 17. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 18. ? @ 0x00007fbc6213eac3 19. ? @ 0x00007fbc621d0850 2025.07.28 11:50:58.077021 [ 4581 ] {e4591a05-f997-4935-a470-3c38a58f62cf} DynamicQueryHandler: Code: 253. DB::Exception: Replica r1 of shard s1 of replicated database at /test/db/test_8 already exists. Replica host ID: '146b4357c08d:9000:ee38db95-0be7-448e-98e5-40a61c7cf34b', current host ID: '146b4357c08d:9000:d8be73e5-56ff-4b08-b137-186281148d58'. (REPLICA_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.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&) @ 0x0000000013db5399 4. /build/src/Databases/DatabaseReplicated.cpp:494: DB::DatabaseReplicated::tryConnectToZooKeeperAndInitDatabase(DB::LoadingStrictnessLevel) @ 0x0000000013d91155 5. /build/src/Databases/DatabaseReplicated.cpp:735: DB::DatabaseReplicated::beforeLoadingMetadata(std::shared_ptr, DB::LoadingStrictnessLevel) @ 0x0000000013d954d4 6. /build/src/Databases/TablesLoader.cpp:57: DB::TablesLoader::loadTablesAsync(std::unordered_set, std::hash>, std::equal_to>, std::allocator>>) @ 0x000000001490e734 7. /build/src/Interpreters/InterpreterCreateQuery.cpp:383: DB::InterpreterCreateQuery::createDatabase(DB::ASTCreateQuery&) @ 0x00000000148e8e14 8. /build/src/Interpreters/InterpreterCreateQuery.cpp:2351: DB::InterpreterCreateQuery::execute() @ 0x0000000014905a3a 9. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88dc9 10. /build/src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x0000000014c8ca7b 11. /build/src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000001686da12 12. /build/src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x0000000016870807 13. /build/src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x0000000016907e99 14. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 15. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 16. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 17. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 18. ? @ 0x00007fbc6213eac3 19. ? @ 0x00007fbc621d0850 (version 25.3.6.10636.altinitytest (altinity build)) 2025.07.28 11:50:58.141537 [ 12807 ] {e75074af-31c1-4ae8-93c6-630b1e47ea67} executeQuery: Code: 253. DB::Exception: Replica r1 of shard s1 of replicated database at /test/db/test_8 already exists. Replica host ID: '146b4357c08d:9000:ee38db95-0be7-448e-98e5-40a61c7cf34b', current host ID: '146b4357c08d:9000:75e282d6-4772-4264-9824-1907e9f88ca4'. (REPLICA_ALREADY_EXISTS) (version 25.3.6.10636.altinitytest (altinity build)) (from [::1]:50218) (comment: 03297_input_compression_autodetect.sh) (in query: CREATE DATABASE IF NOT EXISTS test_as00rny3 ENGINE=Replicated('/test/db/test_8', 's1', 'r1') ), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.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&) @ 0x0000000013db5399 4. /build/src/Databases/DatabaseReplicated.cpp:494: DB::DatabaseReplicated::tryConnectToZooKeeperAndInitDatabase(DB::LoadingStrictnessLevel) @ 0x0000000013d91155 5. /build/src/Databases/DatabaseReplicated.cpp:735: DB::DatabaseReplicated::beforeLoadingMetadata(std::shared_ptr, DB::LoadingStrictnessLevel) @ 0x0000000013d954d4 6. /build/src/Databases/TablesLoader.cpp:57: DB::TablesLoader::loadTablesAsync(std::unordered_set, std::hash>, std::equal_to>, std::allocator>>) @ 0x000000001490e734 7. /build/src/Interpreters/InterpreterCreateQuery.cpp:383: DB::InterpreterCreateQuery::createDatabase(DB::ASTCreateQuery&) @ 0x00000000148e8e14 8. /build/src/Interpreters/InterpreterCreateQuery.cpp:2351: DB::InterpreterCreateQuery::execute() @ 0x0000000014905a3a 9. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88dc9 10. /build/src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x0000000014c8ca7b 11. /build/src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000001686da12 12. /build/src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x0000000016870807 13. /build/src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x0000000016907e99 14. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 15. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 16. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 17. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 18. ? @ 0x00007fbc6213eac3 19. ? @ 0x00007fbc621d0850 2025.07.28 11:50:58.145164 [ 12807 ] {e75074af-31c1-4ae8-93c6-630b1e47ea67} DynamicQueryHandler: Code: 253. DB::Exception: Replica r1 of shard s1 of replicated database at /test/db/test_8 already exists. Replica host ID: '146b4357c08d:9000:ee38db95-0be7-448e-98e5-40a61c7cf34b', current host ID: '146b4357c08d:9000:75e282d6-4772-4264-9824-1907e9f88ca4'. (REPLICA_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.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&) @ 0x0000000013db5399 4. /build/src/Databases/DatabaseReplicated.cpp:494: DB::DatabaseReplicated::tryConnectToZooKeeperAndInitDatabase(DB::LoadingStrictnessLevel) @ 0x0000000013d91155 5. /build/src/Databases/DatabaseReplicated.cpp:735: DB::DatabaseReplicated::beforeLoadingMetadata(std::shared_ptr, DB::LoadingStrictnessLevel) @ 0x0000000013d954d4 6. /build/src/Databases/TablesLoader.cpp:57: DB::TablesLoader::loadTablesAsync(std::unordered_set, std::hash>, std::equal_to>, std::allocator>>) @ 0x000000001490e734 7. /build/src/Interpreters/InterpreterCreateQuery.cpp:383: DB::InterpreterCreateQuery::createDatabase(DB::ASTCreateQuery&) @ 0x00000000148e8e14 8. /build/src/Interpreters/InterpreterCreateQuery.cpp:2351: DB::InterpreterCreateQuery::execute() @ 0x0000000014905a3a 9. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88dc9 10. /build/src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x0000000014c8ca7b 11. /build/src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000001686da12 12. /build/src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x0000000016870807 13. /build/src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x0000000016907e99 14. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 15. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 16. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 17. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 18. ? @ 0x00007fbc6213eac3 19. ? @ 0x00007fbc621d0850 (version 25.3.6.10636.altinitytest (altinity build)) 2025.07.28 11:50:58.255663 [ 11826 ] {b6f4409c-e627-434e-8000-688d24c1a517} executeQuery: Code: 253. DB::Exception: Replica r1 of shard s1 of replicated database at /test/db/test_8 already exists. Replica host ID: '146b4357c08d:9000:ee38db95-0be7-448e-98e5-40a61c7cf34b', current host ID: '146b4357c08d:9000:a6f4b088-cb29-4fee-800e-d371c72b8940'. (REPLICA_ALREADY_EXISTS) (version 25.3.6.10636.altinitytest (altinity build)) (from [::1]:50230) (comment: 02784_projections_read_in_order_bug.sql) (in query: CREATE DATABASE IF NOT EXISTS test_lyq5avfb ENGINE=Replicated('/test/db/test_8', 's1', 'r1') ), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.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&) @ 0x0000000013db5399 4. /build/src/Databases/DatabaseReplicated.cpp:494: DB::DatabaseReplicated::tryConnectToZooKeeperAndInitDatabase(DB::LoadingStrictnessLevel) @ 0x0000000013d91155 5. /build/src/Databases/DatabaseReplicated.cpp:735: DB::DatabaseReplicated::beforeLoadingMetadata(std::shared_ptr, DB::LoadingStrictnessLevel) @ 0x0000000013d954d4 6. /build/src/Databases/TablesLoader.cpp:57: DB::TablesLoader::loadTablesAsync(std::unordered_set, std::hash>, std::equal_to>, std::allocator>>) @ 0x000000001490e734 7. /build/src/Interpreters/InterpreterCreateQuery.cpp:383: DB::InterpreterCreateQuery::createDatabase(DB::ASTCreateQuery&) @ 0x00000000148e8e14 8. /build/src/Interpreters/InterpreterCreateQuery.cpp:2351: DB::InterpreterCreateQuery::execute() @ 0x0000000014905a3a 9. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88dc9 10. /build/src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x0000000014c8ca7b 11. /build/src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000001686da12 12. /build/src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x0000000016870807 13. /build/src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x0000000016907e99 14. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 15. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 16. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 17. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 18. ? @ 0x00007fbc6213eac3 19. ? @ 0x00007fbc621d0850 2025.07.28 11:50:58.266688 [ 11826 ] {b6f4409c-e627-434e-8000-688d24c1a517} DynamicQueryHandler: Code: 253. DB::Exception: Replica r1 of shard s1 of replicated database at /test/db/test_8 already exists. Replica host ID: '146b4357c08d:9000:ee38db95-0be7-448e-98e5-40a61c7cf34b', current host ID: '146b4357c08d:9000:a6f4b088-cb29-4fee-800e-d371c72b8940'. (REPLICA_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.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&) @ 0x0000000013db5399 4. /build/src/Databases/DatabaseReplicated.cpp:494: DB::DatabaseReplicated::tryConnectToZooKeeperAndInitDatabase(DB::LoadingStrictnessLevel) @ 0x0000000013d91155 5. /build/src/Databases/DatabaseReplicated.cpp:735: DB::DatabaseReplicated::beforeLoadingMetadata(std::shared_ptr, DB::LoadingStrictnessLevel) @ 0x0000000013d954d4 6. /build/src/Databases/TablesLoader.cpp:57: DB::TablesLoader::loadTablesAsync(std::unordered_set, std::hash>, std::equal_to>, std::allocator>>) @ 0x000000001490e734 7. /build/src/Interpreters/InterpreterCreateQuery.cpp:383: DB::InterpreterCreateQuery::createDatabase(DB::ASTCreateQuery&) @ 0x00000000148e8e14 8. /build/src/Interpreters/InterpreterCreateQuery.cpp:2351: DB::InterpreterCreateQuery::execute() @ 0x0000000014905a3a 9. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88dc9 10. /build/src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x0000000014c8ca7b 11. /build/src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000001686da12 12. /build/src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x0000000016870807 13. /build/src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x0000000016907e99 14. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 15. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 16. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 17. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 18. ? @ 0x00007fbc6213eac3 19. ? @ 0x00007fbc621d0850 (version 25.3.6.10636.altinitytest (altinity build)) 2025.07.28 11:50:58.414381 [ 3335 ] {} 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. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000fccaeeb 4. /build/src/Common/ThreadPool.cpp:275: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000fccc813 5. /build/src/Common/ThreadPool.cpp:323: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fcc7bbc 6. /build/src/Common/ThreadPool.cpp:494: ThreadPoolImpl>::scheduleOrThrowOnError(std::function, Priority) @ 0x000000000fcc7a0e 7. /build/src/Common/threadPoolCallbackRunner.h:188: DB::ThreadPoolCallbackRunnerLocal>, std::function>::operator()(std::function&&, Priority, std::optional) @ 0x00000000119df78e 8. /build/src/Interpreters/DatabaseCatalog.cpp:1360: DB::DatabaseCatalog::dropTablesParallel(std::vector, std::allocator>>) @ 0x00000000144fcff9 9. /build/src/Interpreters/DatabaseCatalog.cpp:1382: DB::DatabaseCatalog::dropTableDataTask() @ 0x00000000144fd4fc 10. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000139630d4 11. /build/src/Core/BackgroundSchedulePool.cpp:308: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001396616a 12. /build/src/Core/BackgroundSchedulePool.cpp:171: void std::__function::__policy_invoker::__call_impl[abi:se190107]::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_1>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_1&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001396690a 13. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc3d92 14. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fcca080 15. ? @ 0x00007fbc6213eac3 16. ? @ 0x00007fbc621d0850 (version 25.3.6.10636.altinitytest (altinity build)) 2025.07.28 11:50:58.452371 [ 3287 ] {d1434482-15b8-49e3-beb4-98e51fa4e8e3} executeQuery: Code: 253. DB::Exception: Replica r1 of shard s1 of replicated database at /test/db/test_8 already exists. Replica host ID: '146b4357c08d:9000:ee38db95-0be7-448e-98e5-40a61c7cf34b', current host ID: '146b4357c08d:9000:3920ebbe-80ef-49ba-8a37-d32c58902640'. (REPLICA_ALREADY_EXISTS) (version 25.3.6.10636.altinitytest (altinity build)) (from [::1]:50258) (comment: 03285_materialize_ttl_only_drop_parts.sql) (in query: CREATE DATABASE IF NOT EXISTS test_wi6pb6no ENGINE=Replicated('/test/db/test_8', 's1', 'r1') ), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.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&) @ 0x0000000013db5399 4. /build/src/Databases/DatabaseReplicated.cpp:494: DB::DatabaseReplicated::tryConnectToZooKeeperAndInitDatabase(DB::LoadingStrictnessLevel) @ 0x0000000013d91155 5. /build/src/Databases/DatabaseReplicated.cpp:735: DB::DatabaseReplicated::beforeLoadingMetadata(std::shared_ptr, DB::LoadingStrictnessLevel) @ 0x0000000013d954d4 6. /build/src/Databases/TablesLoader.cpp:57: DB::TablesLoader::loadTablesAsync(std::unordered_set, std::hash>, std::equal_to>, std::allocator>>) @ 0x000000001490e734 7. /build/src/Interpreters/InterpreterCreateQuery.cpp:383: DB::InterpreterCreateQuery::createDatabase(DB::ASTCreateQuery&) @ 0x00000000148e8e14 8. /build/src/Interpreters/InterpreterCreateQuery.cpp:2351: DB::InterpreterCreateQuery::execute() @ 0x0000000014905a3a 9. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88dc9 10. /build/src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x0000000014c8ca7b 11. /build/src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000001686da12 12. /build/src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x0000000016870807 13. /build/src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x0000000016907e99 14. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 15. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 16. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 17. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 18. ? @ 0x00007fbc6213eac3 19. ? @ 0x00007fbc621d0850 2025.07.28 11:50:58.455550 [ 3287 ] {d1434482-15b8-49e3-beb4-98e51fa4e8e3} DynamicQueryHandler: Code: 253. DB::Exception: Replica r1 of shard s1 of replicated database at /test/db/test_8 already exists. Replica host ID: '146b4357c08d:9000:ee38db95-0be7-448e-98e5-40a61c7cf34b', current host ID: '146b4357c08d:9000:3920ebbe-80ef-49ba-8a37-d32c58902640'. (REPLICA_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.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&) @ 0x0000000013db5399 4. /build/src/Databases/DatabaseReplicated.cpp:494: DB::DatabaseReplicated::tryConnectToZooKeeperAndInitDatabase(DB::LoadingStrictnessLevel) @ 0x0000000013d91155 5. /build/src/Databases/DatabaseReplicated.cpp:735: DB::DatabaseReplicated::beforeLoadingMetadata(std::shared_ptr, DB::LoadingStrictnessLevel) @ 0x0000000013d954d4 6. /build/src/Databases/TablesLoader.cpp:57: DB::TablesLoader::loadTablesAsync(std::unordered_set, std::hash>, std::equal_to>, std::allocator>>) @ 0x000000001490e734 7. /build/src/Interpreters/InterpreterCreateQuery.cpp:383: DB::InterpreterCreateQuery::createDatabase(DB::ASTCreateQuery&) @ 0x00000000148e8e14 8. /build/src/Interpreters/InterpreterCreateQuery.cpp:2351: DB::InterpreterCreateQuery::execute() @ 0x0000000014905a3a 9. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88dc9 10. /build/src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x0000000014c8ca7b 11. /build/src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000001686da12 12. /build/src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x0000000016870807 13. /build/src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x0000000016907e99 14. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 15. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 16. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 17. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 18. ? @ 0x00007fbc6213eac3 19. ? @ 0x00007fbc621d0850 (version 25.3.6.10636.altinitytest (altinity build)) 2025.07.28 11:50:58.581998 [ 12454 ] {78b6b491-912a-45fa-8a78-770976a10e8c} executeQuery: Code: 253. DB::Exception: Replica r1 of shard s1 of replicated database at /test/db/test_8 already exists. Replica host ID: '146b4357c08d:9000:ee38db95-0be7-448e-98e5-40a61c7cf34b', current host ID: '146b4357c08d:9000:f13dacd1-08b0-4156-8d0c-12d0e9568ab8'. (REPLICA_ALREADY_EXISTS) (version 25.3.6.10636.altinitytest (altinity build)) (from [::1]:50270) (comment: 02167_columns_with_dots_default_values.sql) (in query: CREATE DATABASE IF NOT EXISTS test_ea9jyba7 ENGINE=Replicated('/test/db/test_8', 's1', 'r1') ), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.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&) @ 0x0000000013db5399 4. /build/src/Databases/DatabaseReplicated.cpp:494: DB::DatabaseReplicated::tryConnectToZooKeeperAndInitDatabase(DB::LoadingStrictnessLevel) @ 0x0000000013d91155 5. /build/src/Databases/DatabaseReplicated.cpp:735: DB::DatabaseReplicated::beforeLoadingMetadata(std::shared_ptr, DB::LoadingStrictnessLevel) @ 0x0000000013d954d4 6. /build/src/Databases/TablesLoader.cpp:57: DB::TablesLoader::loadTablesAsync(std::unordered_set, std::hash>, std::equal_to>, std::allocator>>) @ 0x000000001490e734 7. /build/src/Interpreters/InterpreterCreateQuery.cpp:383: DB::InterpreterCreateQuery::createDatabase(DB::ASTCreateQuery&) @ 0x00000000148e8e14 8. /build/src/Interpreters/InterpreterCreateQuery.cpp:2351: DB::InterpreterCreateQuery::execute() @ 0x0000000014905a3a 9. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88dc9 10. /build/src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x0000000014c8ca7b 11. /build/src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000001686da12 12. /build/src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x0000000016870807 13. /build/src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x0000000016907e99 14. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 15. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 16. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 17. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 18. ? @ 0x00007fbc6213eac3 19. ? @ 0x00007fbc621d0850 2025.07.28 11:50:58.599257 [ 12454 ] {78b6b491-912a-45fa-8a78-770976a10e8c} DynamicQueryHandler: Code: 253. DB::Exception: Replica r1 of shard s1 of replicated database at /test/db/test_8 already exists. Replica host ID: '146b4357c08d:9000:ee38db95-0be7-448e-98e5-40a61c7cf34b', current host ID: '146b4357c08d:9000:f13dacd1-08b0-4156-8d0c-12d0e9568ab8'. (REPLICA_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.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&) @ 0x0000000013db5399 4. /build/src/Databases/DatabaseReplicated.cpp:494: DB::DatabaseReplicated::tryConnectToZooKeeperAndInitDatabase(DB::LoadingStrictnessLevel) @ 0x0000000013d91155 5. /build/src/Databases/DatabaseReplicated.cpp:735: DB::DatabaseReplicated::beforeLoadingMetadata(std::shared_ptr, DB::LoadingStrictnessLevel) @ 0x0000000013d954d4 6. /build/src/Databases/TablesLoader.cpp:57: DB::TablesLoader::loadTablesAsync(std::unordered_set, std::hash>, std::equal_to>, std::allocator>>) @ 0x000000001490e734 7. /build/src/Interpreters/InterpreterCreateQuery.cpp:383: DB::InterpreterCreateQuery::createDatabase(DB::ASTCreateQuery&) @ 0x00000000148e8e14 8. /build/src/Interpreters/InterpreterCreateQuery.cpp:2351: DB::InterpreterCreateQuery::execute() @ 0x0000000014905a3a 9. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88dc9 10. /build/src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x0000000014c8ca7b 11. /build/src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000001686da12 12. /build/src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x0000000016870807 13. /build/src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x0000000016907e99 14. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 15. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 16. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 17. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 18. ? @ 0x00007fbc6213eac3 19. ? @ 0x00007fbc621d0850 (version 25.3.6.10636.altinitytest (altinity build)) 2025.07.28 11:50:58.677917 [ 12807 ] {f6b74c3f-66d9-4245-b7c7-85e35abf3421} executeQuery: Code: 253. DB::Exception: Replica r1 of shard s1 of replicated database at /test/db/test_8 already exists. Replica host ID: '146b4357c08d:9000:ee38db95-0be7-448e-98e5-40a61c7cf34b', current host ID: '146b4357c08d:9000:d4d821c6-8a41-45d3-bfee-b4ef873bd506'. (REPLICA_ALREADY_EXISTS) (version 25.3.6.10636.altinitytest (altinity build)) (from [::1]:50290) (comment: 02789_jit_cannot_convert_column.sql) (in query: CREATE DATABASE IF NOT EXISTS test_zkrl43ef ENGINE=Replicated('/test/db/test_8', 's1', 'r1') ), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.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&) @ 0x0000000013db5399 4. /build/src/Databases/DatabaseReplicated.cpp:494: DB::DatabaseReplicated::tryConnectToZooKeeperAndInitDatabase(DB::LoadingStrictnessLevel) @ 0x0000000013d91155 5. /build/src/Databases/DatabaseReplicated.cpp:735: DB::DatabaseReplicated::beforeLoadingMetadata(std::shared_ptr, DB::LoadingStrictnessLevel) @ 0x0000000013d954d4 6. /build/src/Databases/TablesLoader.cpp:57: DB::TablesLoader::loadTablesAsync(std::unordered_set, std::hash>, std::equal_to>, std::allocator>>) @ 0x000000001490e734 7. /build/src/Interpreters/InterpreterCreateQuery.cpp:383: DB::InterpreterCreateQuery::createDatabase(DB::ASTCreateQuery&) @ 0x00000000148e8e14 8. /build/src/Interpreters/InterpreterCreateQuery.cpp:2351: DB::InterpreterCreateQuery::execute() @ 0x0000000014905a3a 9. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88dc9 10. /build/src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x0000000014c8ca7b 11. /build/src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000001686da12 12. /build/src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x0000000016870807 13. /build/src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x0000000016907e99 14. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 15. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 16. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 17. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 18. ? @ 0x00007fbc6213eac3 19. ? @ 0x00007fbc621d0850 2025.07.28 11:50:58.682511 [ 12807 ] {f6b74c3f-66d9-4245-b7c7-85e35abf3421} DynamicQueryHandler: Code: 253. DB::Exception: Replica r1 of shard s1 of replicated database at /test/db/test_8 already exists. Replica host ID: '146b4357c08d:9000:ee38db95-0be7-448e-98e5-40a61c7cf34b', current host ID: '146b4357c08d:9000:d4d821c6-8a41-45d3-bfee-b4ef873bd506'. (REPLICA_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.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&) @ 0x0000000013db5399 4. /build/src/Databases/DatabaseReplicated.cpp:494: DB::DatabaseReplicated::tryConnectToZooKeeperAndInitDatabase(DB::LoadingStrictnessLevel) @ 0x0000000013d91155 5. /build/src/Databases/DatabaseReplicated.cpp:735: DB::DatabaseReplicated::beforeLoadingMetadata(std::shared_ptr, DB::LoadingStrictnessLevel) @ 0x0000000013d954d4 6. /build/src/Databases/TablesLoader.cpp:57: DB::TablesLoader::loadTablesAsync(std::unordered_set, std::hash>, std::equal_to>, std::allocator>>) @ 0x000000001490e734 7. /build/src/Interpreters/InterpreterCreateQuery.cpp:383: DB::InterpreterCreateQuery::createDatabase(DB::ASTCreateQuery&) @ 0x00000000148e8e14 8. /build/src/Interpreters/InterpreterCreateQuery.cpp:2351: DB::InterpreterCreateQuery::execute() @ 0x0000000014905a3a 9. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88dc9 10. /build/src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x0000000014c8ca7b 11. /build/src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000001686da12 12. /build/src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x0000000016870807 13. /build/src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x0000000016907e99 14. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 15. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 16. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 17. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 18. ? @ 0x00007fbc6213eac3 19. ? @ 0x00007fbc621d0850 (version 25.3.6.10636.altinitytest (altinity build)) 2025.07.28 11:50:58.847757 [ 4581 ] {025f78ec-5327-43ba-aa4f-b0ff84f15dba} executeQuery: Code: 253. DB::Exception: Replica r1 of shard s1 of replicated database at /test/db/test_8 already exists. Replica host ID: '146b4357c08d:9000:ee38db95-0be7-448e-98e5-40a61c7cf34b', current host ID: '146b4357c08d:9000:cd705bb4-78bd-4a3d-a594-f016e7eff8ec'. (REPLICA_ALREADY_EXISTS) (version 25.3.6.10636.altinitytest (altinity build)) (from [::1]:50294) (comment: 02448_clone_replica_lost_part.sql) (in query: CREATE DATABASE IF NOT EXISTS test_qomfgd3l ENGINE=Replicated('/test/db/test_8', 's1', 'r1') ), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.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&) @ 0x0000000013db5399 4. /build/src/Databases/DatabaseReplicated.cpp:494: DB::DatabaseReplicated::tryConnectToZooKeeperAndInitDatabase(DB::LoadingStrictnessLevel) @ 0x0000000013d91155 5. /build/src/Databases/DatabaseReplicated.cpp:735: DB::DatabaseReplicated::beforeLoadingMetadata(std::shared_ptr, DB::LoadingStrictnessLevel) @ 0x0000000013d954d4 6. /build/src/Databases/TablesLoader.cpp:57: DB::TablesLoader::loadTablesAsync(std::unordered_set, std::hash>, std::equal_to>, std::allocator>>) @ 0x000000001490e734 7. /build/src/Interpreters/InterpreterCreateQuery.cpp:383: DB::InterpreterCreateQuery::createDatabase(DB::ASTCreateQuery&) @ 0x00000000148e8e14 8. /build/src/Interpreters/InterpreterCreateQuery.cpp:2351: DB::InterpreterCreateQuery::execute() @ 0x0000000014905a3a 9. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88dc9 10. /build/src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x0000000014c8ca7b 11. /build/src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000001686da12 12. /build/src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x0000000016870807 13. /build/src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x0000000016907e99 14. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 15. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 16. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 17. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 18. ? @ 0x00007fbc6213eac3 19. ? @ 0x00007fbc621d0850 2025.07.28 11:50:58.850218 [ 4581 ] {025f78ec-5327-43ba-aa4f-b0ff84f15dba} DynamicQueryHandler: Code: 253. DB::Exception: Replica r1 of shard s1 of replicated database at /test/db/test_8 already exists. Replica host ID: '146b4357c08d:9000:ee38db95-0be7-448e-98e5-40a61c7cf34b', current host ID: '146b4357c08d:9000:cd705bb4-78bd-4a3d-a594-f016e7eff8ec'. (REPLICA_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.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&) @ 0x0000000013db5399 4. /build/src/Databases/DatabaseReplicated.cpp:494: DB::DatabaseReplicated::tryConnectToZooKeeperAndInitDatabase(DB::LoadingStrictnessLevel) @ 0x0000000013d91155 5. /build/src/Databases/DatabaseReplicated.cpp:735: DB::DatabaseReplicated::beforeLoadingMetadata(std::shared_ptr, DB::LoadingStrictnessLevel) @ 0x0000000013d954d4 6. /build/src/Databases/TablesLoader.cpp:57: DB::TablesLoader::loadTablesAsync(std::unordered_set, std::hash>, std::equal_to>, std::allocator>>) @ 0x000000001490e734 7. /build/src/Interpreters/InterpreterCreateQuery.cpp:383: DB::InterpreterCreateQuery::createDatabase(DB::ASTCreateQuery&) @ 0x00000000148e8e14 8. /build/src/Interpreters/InterpreterCreateQuery.cpp:2351: DB::InterpreterCreateQuery::execute() @ 0x0000000014905a3a 9. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88dc9 10. /build/src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x0000000014c8ca7b 11. /build/src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000001686da12 12. /build/src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x0000000016870807 13. /build/src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x0000000016907e99 14. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 15. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 16. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 17. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 18. ? @ 0x00007fbc6213eac3 19. ? @ 0x00007fbc621d0850 (version 25.3.6.10636.altinitytest (altinity build)) 2025.07.28 11:50:58.983095 [ 4581 ] {63585e35-e251-4fa0-a579-d9cdedeff8c4} executeQuery: Code: 253. DB::Exception: Replica r1 of shard s1 of replicated database at /test/db/test_8 already exists. Replica host ID: '146b4357c08d:9000:ee38db95-0be7-448e-98e5-40a61c7cf34b', current host ID: '146b4357c08d:9000:31307175-6c8d-4c4c-baef-5576994eda38'. (REPLICA_ALREADY_EXISTS) (version 25.3.6.10636.altinitytest (altinity build)) (from [::1]:50300) (comment: 00753_alter_attach.sql) (in query: CREATE DATABASE IF NOT EXISTS test_0ulykyur ENGINE=Replicated('/test/db/test_8', 's1', 'r1') ), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.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&) @ 0x0000000013db5399 4. /build/src/Databases/DatabaseReplicated.cpp:494: DB::DatabaseReplicated::tryConnectToZooKeeperAndInitDatabase(DB::LoadingStrictnessLevel) @ 0x0000000013d91155 5. /build/src/Databases/DatabaseReplicated.cpp:735: DB::DatabaseReplicated::beforeLoadingMetadata(std::shared_ptr, DB::LoadingStrictnessLevel) @ 0x0000000013d954d4 6. /build/src/Databases/TablesLoader.cpp:57: DB::TablesLoader::loadTablesAsync(std::unordered_set, std::hash>, std::equal_to>, std::allocator>>) @ 0x000000001490e734 7. /build/src/Interpreters/InterpreterCreateQuery.cpp:383: DB::InterpreterCreateQuery::createDatabase(DB::ASTCreateQuery&) @ 0x00000000148e8e14 8. /build/src/Interpreters/InterpreterCreateQuery.cpp:2351: DB::InterpreterCreateQuery::execute() @ 0x0000000014905a3a 9. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88dc9 10. /build/src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x0000000014c8ca7b 11. /build/src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000001686da12 12. /build/src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x0000000016870807 13. /build/src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x0000000016907e99 14. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 15. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 16. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 17. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 18. ? @ 0x00007fbc6213eac3 19. ? @ 0x00007fbc621d0850 2025.07.28 11:50:58.987987 [ 4581 ] {63585e35-e251-4fa0-a579-d9cdedeff8c4} DynamicQueryHandler: Code: 253. DB::Exception: Replica r1 of shard s1 of replicated database at /test/db/test_8 already exists. Replica host ID: '146b4357c08d:9000:ee38db95-0be7-448e-98e5-40a61c7cf34b', current host ID: '146b4357c08d:9000:31307175-6c8d-4c4c-baef-5576994eda38'. (REPLICA_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.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&) @ 0x0000000013db5399 4. /build/src/Databases/DatabaseReplicated.cpp:494: DB::DatabaseReplicated::tryConnectToZooKeeperAndInitDatabase(DB::LoadingStrictnessLevel) @ 0x0000000013d91155 5. /build/src/Databases/DatabaseReplicated.cpp:735: DB::DatabaseReplicated::beforeLoadingMetadata(std::shared_ptr, DB::LoadingStrictnessLevel) @ 0x0000000013d954d4 6. /build/src/Databases/TablesLoader.cpp:57: DB::TablesLoader::loadTablesAsync(std::unordered_set, std::hash>, std::equal_to>, std::allocator>>) @ 0x000000001490e734 7. /build/src/Interpreters/InterpreterCreateQuery.cpp:383: DB::InterpreterCreateQuery::createDatabase(DB::ASTCreateQuery&) @ 0x00000000148e8e14 8. /build/src/Interpreters/InterpreterCreateQuery.cpp:2351: DB::InterpreterCreateQuery::execute() @ 0x0000000014905a3a 9. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88dc9 10. /build/src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x0000000014c8ca7b 11. /build/src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000001686da12 12. /build/src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x0000000016870807 13. /build/src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x0000000016907e99 14. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 15. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 16. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 17. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 18. ? @ 0x00007fbc6213eac3 19. ? @ 0x00007fbc621d0850 (version 25.3.6.10636.altinitytest (altinity build)) 2025.07.28 11:50:59.077691 [ 3285 ] {b2750954-3fdd-4680-9fa8-c329fc02eb95} executeQuery: Code: 253. DB::Exception: Replica r1 of shard s1 of replicated database at /test/db/test_8 already exists. Replica host ID: '146b4357c08d:9000:ee38db95-0be7-448e-98e5-40a61c7cf34b', current host ID: '146b4357c08d:9000:6181721c-2984-446e-bb7f-6ffa1a333777'. (REPLICA_ALREADY_EXISTS) (version 25.3.6.10636.altinitytest (altinity build)) (from [::1]:50314) (comment: 03241_orc_dictionary_encode.sql) (in query: CREATE DATABASE IF NOT EXISTS test_80hnv756 ENGINE=Replicated('/test/db/test_8', 's1', 'r1') ), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.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&) @ 0x0000000013db5399 4. /build/src/Databases/DatabaseReplicated.cpp:494: DB::DatabaseReplicated::tryConnectToZooKeeperAndInitDatabase(DB::LoadingStrictnessLevel) @ 0x0000000013d91155 5. /build/src/Databases/DatabaseReplicated.cpp:735: DB::DatabaseReplicated::beforeLoadingMetadata(std::shared_ptr, DB::LoadingStrictnessLevel) @ 0x0000000013d954d4 6. /build/src/Databases/TablesLoader.cpp:57: DB::TablesLoader::loadTablesAsync(std::unordered_set, std::hash>, std::equal_to>, std::allocator>>) @ 0x000000001490e734 7. /build/src/Interpreters/InterpreterCreateQuery.cpp:383: DB::InterpreterCreateQuery::createDatabase(DB::ASTCreateQuery&) @ 0x00000000148e8e14 8. /build/src/Interpreters/InterpreterCreateQuery.cpp:2351: DB::InterpreterCreateQuery::execute() @ 0x0000000014905a3a 9. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88dc9 10. /build/src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x0000000014c8ca7b 11. /build/src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000001686da12 12. /build/src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x0000000016870807 13. /build/src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x0000000016907e99 14. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 15. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 16. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 17. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 18. ? @ 0x00007fbc6213eac3 19. ? @ 0x00007fbc621d0850 2025.07.28 11:50:59.087730 [ 3285 ] {b2750954-3fdd-4680-9fa8-c329fc02eb95} DynamicQueryHandler: Code: 253. DB::Exception: Replica r1 of shard s1 of replicated database at /test/db/test_8 already exists. Replica host ID: '146b4357c08d:9000:ee38db95-0be7-448e-98e5-40a61c7cf34b', current host ID: '146b4357c08d:9000:6181721c-2984-446e-bb7f-6ffa1a333777'. (REPLICA_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.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&) @ 0x0000000013db5399 4. /build/src/Databases/DatabaseReplicated.cpp:494: DB::DatabaseReplicated::tryConnectToZooKeeperAndInitDatabase(DB::LoadingStrictnessLevel) @ 0x0000000013d91155 5. /build/src/Databases/DatabaseReplicated.cpp:735: DB::DatabaseReplicated::beforeLoadingMetadata(std::shared_ptr, DB::LoadingStrictnessLevel) @ 0x0000000013d954d4 6. /build/src/Databases/TablesLoader.cpp:57: DB::TablesLoader::loadTablesAsync(std::unordered_set, std::hash>, std::equal_to>, std::allocator>>) @ 0x000000001490e734 7. /build/src/Interpreters/InterpreterCreateQuery.cpp:383: DB::InterpreterCreateQuery::createDatabase(DB::ASTCreateQuery&) @ 0x00000000148e8e14 8. /build/src/Interpreters/InterpreterCreateQuery.cpp:2351: DB::InterpreterCreateQuery::execute() @ 0x0000000014905a3a 9. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88dc9 10. /build/src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x0000000014c8ca7b 11. /build/src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000001686da12 12. /build/src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x0000000016870807 13. /build/src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x0000000016907e99 14. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 15. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 16. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 17. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 18. ? @ 0x00007fbc6213eac3 19. ? @ 0x00007fbc621d0850 (version 25.3.6.10636.altinitytest (altinity build)) 2025.07.28 11:50:59.263683 [ 5327 ] {1814fbc9-45f8-49a5-b0ff-e538392bfcaa} executeQuery: Code: 253. DB::Exception: Replica r1 of shard s1 of replicated database at /test/db/test_8 already exists. Replica host ID: '146b4357c08d:9000:ee38db95-0be7-448e-98e5-40a61c7cf34b', current host ID: '146b4357c08d:9000:9b540f66-3c8b-4a24-bc7e-3bdfe3025de8'. (REPLICA_ALREADY_EXISTS) (version 25.3.6.10636.altinitytest (altinity build)) (from [::1]:50324) (comment: 02946_parallel_replicas_force_primary_key.sql) (in query: CREATE DATABASE IF NOT EXISTS test_gp6qvk1z ENGINE=Replicated('/test/db/test_8', 's1', 'r1') ), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.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&) @ 0x0000000013db5399 4. /build/src/Databases/DatabaseReplicated.cpp:494: DB::DatabaseReplicated::tryConnectToZooKeeperAndInitDatabase(DB::LoadingStrictnessLevel) @ 0x0000000013d91155 5. /build/src/Databases/DatabaseReplicated.cpp:735: DB::DatabaseReplicated::beforeLoadingMetadata(std::shared_ptr, DB::LoadingStrictnessLevel) @ 0x0000000013d954d4 6. /build/src/Databases/TablesLoader.cpp:57: DB::TablesLoader::loadTablesAsync(std::unordered_set, std::hash>, std::equal_to>, std::allocator>>) @ 0x000000001490e734 7. /build/src/Interpreters/InterpreterCreateQuery.cpp:383: DB::InterpreterCreateQuery::createDatabase(DB::ASTCreateQuery&) @ 0x00000000148e8e14 8. /build/src/Interpreters/InterpreterCreateQuery.cpp:2351: DB::InterpreterCreateQuery::execute() @ 0x0000000014905a3a 9. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88dc9 10. /build/src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x0000000014c8ca7b 11. /build/src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000001686da12 12. /build/src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x0000000016870807 13. /build/src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x0000000016907e99 14. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 15. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 16. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 17. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 18. ? @ 0x00007fbc6213eac3 19. ? @ 0x00007fbc621d0850 2025.07.28 11:50:59.267038 [ 5327 ] {1814fbc9-45f8-49a5-b0ff-e538392bfcaa} DynamicQueryHandler: Code: 253. DB::Exception: Replica r1 of shard s1 of replicated database at /test/db/test_8 already exists. Replica host ID: '146b4357c08d:9000:ee38db95-0be7-448e-98e5-40a61c7cf34b', current host ID: '146b4357c08d:9000:9b540f66-3c8b-4a24-bc7e-3bdfe3025de8'. (REPLICA_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.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&) @ 0x0000000013db5399 4. /build/src/Databases/DatabaseReplicated.cpp:494: DB::DatabaseReplicated::tryConnectToZooKeeperAndInitDatabase(DB::LoadingStrictnessLevel) @ 0x0000000013d91155 5. /build/src/Databases/DatabaseReplicated.cpp:735: DB::DatabaseReplicated::beforeLoadingMetadata(std::shared_ptr, DB::LoadingStrictnessLevel) @ 0x0000000013d954d4 6. /build/src/Databases/TablesLoader.cpp:57: DB::TablesLoader::loadTablesAsync(std::unordered_set, std::hash>, std::equal_to>, std::allocator>>) @ 0x000000001490e734 7. /build/src/Interpreters/InterpreterCreateQuery.cpp:383: DB::InterpreterCreateQuery::createDatabase(DB::ASTCreateQuery&) @ 0x00000000148e8e14 8. /build/src/Interpreters/InterpreterCreateQuery.cpp:2351: DB::InterpreterCreateQuery::execute() @ 0x0000000014905a3a 9. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88dc9 10. /build/src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x0000000014c8ca7b 11. /build/src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000001686da12 12. /build/src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x0000000016870807 13. /build/src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x0000000016907e99 14. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 15. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 16. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 17. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 18. ? @ 0x00007fbc6213eac3 19. ? @ 0x00007fbc621d0850 (version 25.3.6.10636.altinitytest (altinity build)) 2025.07.28 11:50:59.321005 [ 11851 ] {365f426f-69fb-41e8-8cb4-e8d3ec8c7880} executeQuery: Code: 47. DB::Exception: Unknown expression or function identifier `x` in scope x = 1. (UNKNOWN_IDENTIFIER) (version 25.3.6.10636.altinitytest (altinity build)) (from [::1]:57790) (comment: 01283_strict_resize_bug.sql) (query 4, line 5) (in query: select * from (select sum(number) from num_10m union all select sum(number) from num_10m) limit 1 settings max_block_size = 1024;), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.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&&) @ 0x000000001404b3b9 4. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3771: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000001401b849 5. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3980: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000014018e31 6. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:2925: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000001402fcbd 7. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3838: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000014019a9e 8. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:209: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000001401270e 9. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000014011fce 10. /build/src/Planner/Utils.cpp:458: DB::buildFilterInfo(std::shared_ptr, std::shared_ptr const&, std::shared_ptr&, std::unordered_set, std::equal_to, std::allocator>) @ 0x0000000013fe8bcf 11. /build/src/Planner/PlannerJoinTree.cpp:535: DB::(anonymous namespace)::buildQueryPlanForTableExpression(std::shared_ptr, std::shared_ptr const&, DB::SelectQueryInfo const&, DB::SelectQueryOptions const&, std::shared_ptr&, bool, bool) @ 0x00000000149956d3 12. /build/src/Planner/PlannerJoinTree.cpp:2252: DB::buildJoinTreeQueryPlan(std::shared_ptr const&, DB::SelectQueryInfo const&, DB::SelectQueryOptions&, std::unordered_set, std::equal_to, std::allocator> const&, std::shared_ptr&) @ 0x000000001498e109 13. /build/src/Planner/Planner.cpp:1553: DB::Planner::buildPlanForQueryNode() @ 0x0000000014979dae 14. /build/src/Planner/Planner.cpp:1308: DB::Planner::buildQueryPlanIfNeeded() @ 0x000000001497685c 15. /build/src/Planner/Planner.cpp:1348: DB::Planner::buildPlanForUnionNode() @ 0x0000000014976e4c 16. /build/src/Planner/Planner.cpp:1306: DB::Planner::buildQueryPlanIfNeeded() @ 0x0000000014976855 17. /build/src/Planner/PlannerJoinTree.cpp:1202: DB::(anonymous namespace)::buildQueryPlanForTableExpression(std::shared_ptr, std::shared_ptr const&, DB::SelectQueryInfo const&, DB::SelectQueryOptions const&, std::shared_ptr&, bool, bool) @ 0x0000000014994644 18. /build/src/Planner/PlannerJoinTree.cpp:2252: DB::buildJoinTreeQueryPlan(std::shared_ptr const&, DB::SelectQueryInfo const&, DB::SelectQueryOptions&, std::unordered_set, std::equal_to, std::allocator> const&, std::shared_ptr&) @ 0x000000001498e109 19. /build/src/Planner/Planner.cpp:1553: DB::Planner::buildPlanForQueryNode() @ 0x0000000014979dae 20. /build/src/Planner/Planner.cpp:1308: DB::Planner::buildQueryPlanIfNeeded() @ 0x000000001497685c 21. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:255: DB::InterpreterSelectQueryAnalyzer::getQueryPlan() @ 0x000000001497476d 22. /build/src/Interpreters/executeQuery.cpp:1405: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88806 23. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 24. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 25. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 26. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 27. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 28. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 29. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 30. ? @ 0x00007fbc6213eac3 31. ? @ 0x00007fbc621d0850 2025.07.28 11:50:59.343851 [ 11851 ] {} TCPHandler: Code: 47. DB::Exception: Unknown expression or function identifier `x` in scope x = 1. (UNKNOWN_IDENTIFIER), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.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&&) @ 0x000000001404b3b9 4. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3771: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000001401b849 5. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3980: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000014018e31 6. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:2925: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000001402fcbd 7. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3838: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000014019a9e 8. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:209: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000001401270e 9. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000014011fce 10. /build/src/Planner/Utils.cpp:458: DB::buildFilterInfo(std::shared_ptr, std::shared_ptr const&, std::shared_ptr&, std::unordered_set, std::equal_to, std::allocator>) @ 0x0000000013fe8bcf 11. /build/src/Planner/PlannerJoinTree.cpp:535: DB::(anonymous namespace)::buildQueryPlanForTableExpression(std::shared_ptr, std::shared_ptr const&, DB::SelectQueryInfo const&, DB::SelectQueryOptions const&, std::shared_ptr&, bool, bool) @ 0x00000000149956d3 12. /build/src/Planner/PlannerJoinTree.cpp:2252: DB::buildJoinTreeQueryPlan(std::shared_ptr const&, DB::SelectQueryInfo const&, DB::SelectQueryOptions&, std::unordered_set, std::equal_to, std::allocator> const&, std::shared_ptr&) @ 0x000000001498e109 13. /build/src/Planner/Planner.cpp:1553: DB::Planner::buildPlanForQueryNode() @ 0x0000000014979dae 14. /build/src/Planner/Planner.cpp:1308: DB::Planner::buildQueryPlanIfNeeded() @ 0x000000001497685c 15. /build/src/Planner/Planner.cpp:1348: DB::Planner::buildPlanForUnionNode() @ 0x0000000014976e4c 16. /build/src/Planner/Planner.cpp:1306: DB::Planner::buildQueryPlanIfNeeded() @ 0x0000000014976855 17. /build/src/Planner/PlannerJoinTree.cpp:1202: DB::(anonymous namespace)::buildQueryPlanForTableExpression(std::shared_ptr, std::shared_ptr const&, DB::SelectQueryInfo const&, DB::SelectQueryOptions const&, std::shared_ptr&, bool, bool) @ 0x0000000014994644 18. /build/src/Planner/PlannerJoinTree.cpp:2252: DB::buildJoinTreeQueryPlan(std::shared_ptr const&, DB::SelectQueryInfo const&, DB::SelectQueryOptions&, std::unordered_set, std::equal_to, std::allocator> const&, std::shared_ptr&) @ 0x000000001498e109 19. /build/src/Planner/Planner.cpp:1553: DB::Planner::buildPlanForQueryNode() @ 0x0000000014979dae 20. /build/src/Planner/Planner.cpp:1308: DB::Planner::buildQueryPlanIfNeeded() @ 0x000000001497685c 21. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:255: DB::InterpreterSelectQueryAnalyzer::getQueryPlan() @ 0x000000001497476d 22. /build/src/Interpreters/executeQuery.cpp:1405: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88806 23. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 24. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 25. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 26. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 27. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 28. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 29. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 30. ? @ 0x00007fbc6213eac3 31. ? @ 0x00007fbc621d0850 2025.07.28 11:50:59.407649 [ 3285 ] {40b58e50-5e16-4984-854b-42ababb01986} executeQuery: Code: 253. DB::Exception: Replica r1 of shard s1 of replicated database at /test/db/test_8 already exists. Replica host ID: '146b4357c08d:9000:ee38db95-0be7-448e-98e5-40a61c7cf34b', current host ID: '146b4357c08d:9000:d36d0468-7566-4245-936f-5fd21a4f67bb'. (REPLICA_ALREADY_EXISTS) (version 25.3.6.10636.altinitytest (altinity build)) (from [::1]:50346) (comment: 02811_insert_schema_inference.sql) (in query: CREATE DATABASE IF NOT EXISTS test_922j6yfk ENGINE=Replicated('/test/db/test_8', 's1', 'r1') ), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.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&) @ 0x0000000013db5399 4. /build/src/Databases/DatabaseReplicated.cpp:494: DB::DatabaseReplicated::tryConnectToZooKeeperAndInitDatabase(DB::LoadingStrictnessLevel) @ 0x0000000013d91155 5. /build/src/Databases/DatabaseReplicated.cpp:735: DB::DatabaseReplicated::beforeLoadingMetadata(std::shared_ptr, DB::LoadingStrictnessLevel) @ 0x0000000013d954d4 6. /build/src/Databases/TablesLoader.cpp:57: DB::TablesLoader::loadTablesAsync(std::unordered_set, std::hash>, std::equal_to>, std::allocator>>) @ 0x000000001490e734 7. /build/src/Interpreters/InterpreterCreateQuery.cpp:383: DB::InterpreterCreateQuery::createDatabase(DB::ASTCreateQuery&) @ 0x00000000148e8e14 8. /build/src/Interpreters/InterpreterCreateQuery.cpp:2351: DB::InterpreterCreateQuery::execute() @ 0x0000000014905a3a 9. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88dc9 10. /build/src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x0000000014c8ca7b 11. /build/src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000001686da12 12. /build/src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x0000000016870807 13. /build/src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x0000000016907e99 14. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 15. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 16. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 17. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 18. ? @ 0x00007fbc6213eac3 19. ? @ 0x00007fbc621d0850 2025.07.28 11:50:59.410195 [ 3285 ] {40b58e50-5e16-4984-854b-42ababb01986} DynamicQueryHandler: Code: 253. DB::Exception: Replica r1 of shard s1 of replicated database at /test/db/test_8 already exists. Replica host ID: '146b4357c08d:9000:ee38db95-0be7-448e-98e5-40a61c7cf34b', current host ID: '146b4357c08d:9000:d36d0468-7566-4245-936f-5fd21a4f67bb'. (REPLICA_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.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&) @ 0x0000000013db5399 4. /build/src/Databases/DatabaseReplicated.cpp:494: DB::DatabaseReplicated::tryConnectToZooKeeperAndInitDatabase(DB::LoadingStrictnessLevel) @ 0x0000000013d91155 5. /build/src/Databases/DatabaseReplicated.cpp:735: DB::DatabaseReplicated::beforeLoadingMetadata(std::shared_ptr, DB::LoadingStrictnessLevel) @ 0x0000000013d954d4 6. /build/src/Databases/TablesLoader.cpp:57: DB::TablesLoader::loadTablesAsync(std::unordered_set, std::hash>, std::equal_to>, std::allocator>>) @ 0x000000001490e734 7. /build/src/Interpreters/InterpreterCreateQuery.cpp:383: DB::InterpreterCreateQuery::createDatabase(DB::ASTCreateQuery&) @ 0x00000000148e8e14 8. /build/src/Interpreters/InterpreterCreateQuery.cpp:2351: DB::InterpreterCreateQuery::execute() @ 0x0000000014905a3a 9. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88dc9 10. /build/src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x0000000014c8ca7b 11. /build/src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000001686da12 12. /build/src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x0000000016870807 13. /build/src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x0000000016907e99 14. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 15. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 16. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 17. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 18. ? @ 0x00007fbc6213eac3 19. ? @ 0x00007fbc621d0850 (version 25.3.6.10636.altinitytest (altinity build)) 2025.07.28 11:50:59.700065 [ 12454 ] {1403df3e-6f89-4b28-96d4-b86d9c80747b} executeQuery: Code: 253. DB::Exception: Replica r1 of shard s1 of replicated database at /test/db/test_8 already exists. Replica host ID: '146b4357c08d:9000:ee38db95-0be7-448e-98e5-40a61c7cf34b', current host ID: '146b4357c08d:9000:040dca2c-6492-4988-aed7-1cf3e8a7585e'. (REPLICA_ALREADY_EXISTS) (version 25.3.6.10636.altinitytest (altinity build)) (from [::1]:50376) (comment: 00088_global_in_one_shard_and_rows_before_limit.sql) (in query: CREATE DATABASE IF NOT EXISTS test_hw19enro ENGINE=Replicated('/test/db/test_8', 's1', 'r1') ), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.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&) @ 0x0000000013db5399 4. /build/src/Databases/DatabaseReplicated.cpp:494: DB::DatabaseReplicated::tryConnectToZooKeeperAndInitDatabase(DB::LoadingStrictnessLevel) @ 0x0000000013d91155 5. /build/src/Databases/DatabaseReplicated.cpp:735: DB::DatabaseReplicated::beforeLoadingMetadata(std::shared_ptr, DB::LoadingStrictnessLevel) @ 0x0000000013d954d4 6. /build/src/Databases/TablesLoader.cpp:57: DB::TablesLoader::loadTablesAsync(std::unordered_set, std::hash>, std::equal_to>, std::allocator>>) @ 0x000000001490e734 7. /build/src/Interpreters/InterpreterCreateQuery.cpp:383: DB::InterpreterCreateQuery::createDatabase(DB::ASTCreateQuery&) @ 0x00000000148e8e14 8. /build/src/Interpreters/InterpreterCreateQuery.cpp:2351: DB::InterpreterCreateQuery::execute() @ 0x0000000014905a3a 9. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88dc9 10. /build/src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x0000000014c8ca7b 11. /build/src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000001686da12 12. /build/src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x0000000016870807 13. /build/src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x0000000016907e99 14. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 15. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 16. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 17. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 18. ? @ 0x00007fbc6213eac3 19. ? @ 0x00007fbc621d0850 2025.07.28 11:50:59.717625 [ 12454 ] {1403df3e-6f89-4b28-96d4-b86d9c80747b} DynamicQueryHandler: Code: 253. DB::Exception: Replica r1 of shard s1 of replicated database at /test/db/test_8 already exists. Replica host ID: '146b4357c08d:9000:ee38db95-0be7-448e-98e5-40a61c7cf34b', current host ID: '146b4357c08d:9000:040dca2c-6492-4988-aed7-1cf3e8a7585e'. (REPLICA_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.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&) @ 0x0000000013db5399 4. /build/src/Databases/DatabaseReplicated.cpp:494: DB::DatabaseReplicated::tryConnectToZooKeeperAndInitDatabase(DB::LoadingStrictnessLevel) @ 0x0000000013d91155 5. /build/src/Databases/DatabaseReplicated.cpp:735: DB::DatabaseReplicated::beforeLoadingMetadata(std::shared_ptr, DB::LoadingStrictnessLevel) @ 0x0000000013d954d4 6. /build/src/Databases/TablesLoader.cpp:57: DB::TablesLoader::loadTablesAsync(std::unordered_set, std::hash>, std::equal_to>, std::allocator>>) @ 0x000000001490e734 7. /build/src/Interpreters/InterpreterCreateQuery.cpp:383: DB::InterpreterCreateQuery::createDatabase(DB::ASTCreateQuery&) @ 0x00000000148e8e14 8. /build/src/Interpreters/InterpreterCreateQuery.cpp:2351: DB::InterpreterCreateQuery::execute() @ 0x0000000014905a3a 9. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88dc9 10. /build/src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x0000000014c8ca7b 11. /build/src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000001686da12 12. /build/src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x0000000016870807 13. /build/src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x0000000016907e99 14. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 15. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 16. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 17. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 18. ? @ 0x00007fbc6213eac3 19. ? @ 0x00007fbc621d0850 (version 25.3.6.10636.altinitytest (altinity build)) 2025.07.28 11:50:59.805326 [ 4900 ] {bc3aa3f2-ead8-4fd9-af08-57c4d617f153} executeQuery: Code: 253. DB::Exception: Replica r1 of shard s1 of replicated database at /test/db/test_8 already exists. Replica host ID: '146b4357c08d:9000:ee38db95-0be7-448e-98e5-40a61c7cf34b', current host ID: '146b4357c08d:9000:ce99fe99-5c21-4935-a3d8-00faf9facc1b'. (REPLICA_ALREADY_EXISTS) (version 25.3.6.10636.altinitytest (altinity build)) (from [::1]:50386) (comment: 02724_database_s3.sh) (in query: CREATE DATABASE IF NOT EXISTS test_5kcy4jmf ENGINE=Replicated('/test/db/test_8', 's1', 'r1') ), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.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&) @ 0x0000000013db5399 4. /build/src/Databases/DatabaseReplicated.cpp:494: DB::DatabaseReplicated::tryConnectToZooKeeperAndInitDatabase(DB::LoadingStrictnessLevel) @ 0x0000000013d91155 5. /build/src/Databases/DatabaseReplicated.cpp:735: DB::DatabaseReplicated::beforeLoadingMetadata(std::shared_ptr, DB::LoadingStrictnessLevel) @ 0x0000000013d954d4 6. /build/src/Databases/TablesLoader.cpp:57: DB::TablesLoader::loadTablesAsync(std::unordered_set, std::hash>, std::equal_to>, std::allocator>>) @ 0x000000001490e734 7. /build/src/Interpreters/InterpreterCreateQuery.cpp:383: DB::InterpreterCreateQuery::createDatabase(DB::ASTCreateQuery&) @ 0x00000000148e8e14 8. /build/src/Interpreters/InterpreterCreateQuery.cpp:2351: DB::InterpreterCreateQuery::execute() @ 0x0000000014905a3a 9. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88dc9 10. /build/src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x0000000014c8ca7b 11. /build/src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000001686da12 12. /build/src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x0000000016870807 13. /build/src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x0000000016907e99 14. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 15. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 16. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 17. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 18. ? @ 0x00007fbc6213eac3 19. ? @ 0x00007fbc621d0850 2025.07.28 11:50:59.808131 [ 4900 ] {bc3aa3f2-ead8-4fd9-af08-57c4d617f153} DynamicQueryHandler: Code: 253. DB::Exception: Replica r1 of shard s1 of replicated database at /test/db/test_8 already exists. Replica host ID: '146b4357c08d:9000:ee38db95-0be7-448e-98e5-40a61c7cf34b', current host ID: '146b4357c08d:9000:ce99fe99-5c21-4935-a3d8-00faf9facc1b'. (REPLICA_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.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&) @ 0x0000000013db5399 4. /build/src/Databases/DatabaseReplicated.cpp:494: DB::DatabaseReplicated::tryConnectToZooKeeperAndInitDatabase(DB::LoadingStrictnessLevel) @ 0x0000000013d91155 5. /build/src/Databases/DatabaseReplicated.cpp:735: DB::DatabaseReplicated::beforeLoadingMetadata(std::shared_ptr, DB::LoadingStrictnessLevel) @ 0x0000000013d954d4 6. /build/src/Databases/TablesLoader.cpp:57: DB::TablesLoader::loadTablesAsync(std::unordered_set, std::hash>, std::equal_to>, std::allocator>>) @ 0x000000001490e734 7. /build/src/Interpreters/InterpreterCreateQuery.cpp:383: DB::InterpreterCreateQuery::createDatabase(DB::ASTCreateQuery&) @ 0x00000000148e8e14 8. /build/src/Interpreters/InterpreterCreateQuery.cpp:2351: DB::InterpreterCreateQuery::execute() @ 0x0000000014905a3a 9. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88dc9 10. /build/src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x0000000014c8ca7b 11. /build/src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000001686da12 12. /build/src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x0000000016870807 13. /build/src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x0000000016907e99 14. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 15. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 16. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 17. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 18. ? @ 0x00007fbc6213eac3 19. ? @ 0x00007fbc621d0850 (version 25.3.6.10636.altinitytest (altinity build)) 2025.07.28 11:50:59.985309 [ 5951 ] {fc407da6-e896-440e-a9be-044e57a1c7b7} executeQuery: Code: 253. DB::Exception: Replica r1 of shard s1 of replicated database at /test/db/test_8 already exists. Replica host ID: '146b4357c08d:9000:ee38db95-0be7-448e-98e5-40a61c7cf34b', current host ID: '146b4357c08d:9000:1f2428ea-1e56-4e3d-8977-2f688979f190'. (REPLICA_ALREADY_EXISTS) (version 25.3.6.10636.altinitytest (altinity build)) (from [::1]:50394) (comment: 01268_dictionary_direct_layout.sql) (in query: CREATE DATABASE IF NOT EXISTS test_eetou345 ENGINE=Replicated('/test/db/test_8', 's1', 'r1') ), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.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&) @ 0x0000000013db5399 4. /build/src/Databases/DatabaseReplicated.cpp:494: DB::DatabaseReplicated::tryConnectToZooKeeperAndInitDatabase(DB::LoadingStrictnessLevel) @ 0x0000000013d91155 5. /build/src/Databases/DatabaseReplicated.cpp:735: DB::DatabaseReplicated::beforeLoadingMetadata(std::shared_ptr, DB::LoadingStrictnessLevel) @ 0x0000000013d954d4 6. /build/src/Databases/TablesLoader.cpp:57: DB::TablesLoader::loadTablesAsync(std::unordered_set, std::hash>, std::equal_to>, std::allocator>>) @ 0x000000001490e734 7. /build/src/Interpreters/InterpreterCreateQuery.cpp:383: DB::InterpreterCreateQuery::createDatabase(DB::ASTCreateQuery&) @ 0x00000000148e8e14 8. /build/src/Interpreters/InterpreterCreateQuery.cpp:2351: DB::InterpreterCreateQuery::execute() @ 0x0000000014905a3a 9. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88dc9 10. /build/src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x0000000014c8ca7b 11. /build/src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000001686da12 12. /build/src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x0000000016870807 13. /build/src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x0000000016907e99 14. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 15. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 16. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 17. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 18. ? @ 0x00007fbc6213eac3 19. ? @ 0x00007fbc621d0850 2025.07.28 11:51:00.092735 [ 5951 ] {fc407da6-e896-440e-a9be-044e57a1c7b7} DynamicQueryHandler: Code: 253. DB::Exception: Replica r1 of shard s1 of replicated database at /test/db/test_8 already exists. Replica host ID: '146b4357c08d:9000:ee38db95-0be7-448e-98e5-40a61c7cf34b', current host ID: '146b4357c08d:9000:1f2428ea-1e56-4e3d-8977-2f688979f190'. (REPLICA_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.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&) @ 0x0000000013db5399 4. /build/src/Databases/DatabaseReplicated.cpp:494: DB::DatabaseReplicated::tryConnectToZooKeeperAndInitDatabase(DB::LoadingStrictnessLevel) @ 0x0000000013d91155 5. /build/src/Databases/DatabaseReplicated.cpp:735: DB::DatabaseReplicated::beforeLoadingMetadata(std::shared_ptr, DB::LoadingStrictnessLevel) @ 0x0000000013d954d4 6. /build/src/Databases/TablesLoader.cpp:57: DB::TablesLoader::loadTablesAsync(std::unordered_set, std::hash>, std::equal_to>, std::allocator>>) @ 0x000000001490e734 7. /build/src/Interpreters/InterpreterCreateQuery.cpp:383: DB::InterpreterCreateQuery::createDatabase(DB::ASTCreateQuery&) @ 0x00000000148e8e14 8. /build/src/Interpreters/InterpreterCreateQuery.cpp:2351: DB::InterpreterCreateQuery::execute() @ 0x0000000014905a3a 9. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88dc9 10. /build/src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x0000000014c8ca7b 11. /build/src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000001686da12 12. /build/src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x0000000016870807 13. /build/src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x0000000016907e99 14. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 15. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 16. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 17. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 18. ? @ 0x00007fbc6213eac3 19. ? @ 0x00007fbc621d0850 (version 25.3.6.10636.altinitytest (altinity build)) 2025.07.28 11:51:00.279662 [ 7630 ] {f391729b-a057-431b-bdb4-0db656fb13ca} executeQuery: Code: 253. DB::Exception: Replica r1 of shard s1 of replicated database at /test/db/test_8 already exists. Replica host ID: '146b4357c08d:9000:ee38db95-0be7-448e-98e5-40a61c7cf34b', current host ID: '146b4357c08d:9000:7517a04a-f7ca-4896-a159-3f9b90c5505e'. (REPLICA_ALREADY_EXISTS) (version 25.3.6.10636.altinitytest (altinity build)) (from [::1]:50402) (comment: 00139_like.sql) (in query: CREATE DATABASE IF NOT EXISTS test_015btajk ENGINE=Replicated('/test/db/test_8', 's1', 'r1') ), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.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&) @ 0x0000000013db5399 4. /build/src/Databases/DatabaseReplicated.cpp:494: DB::DatabaseReplicated::tryConnectToZooKeeperAndInitDatabase(DB::LoadingStrictnessLevel) @ 0x0000000013d91155 5. /build/src/Databases/DatabaseReplicated.cpp:735: DB::DatabaseReplicated::beforeLoadingMetadata(std::shared_ptr, DB::LoadingStrictnessLevel) @ 0x0000000013d954d4 6. /build/src/Databases/TablesLoader.cpp:57: DB::TablesLoader::loadTablesAsync(std::unordered_set, std::hash>, std::equal_to>, std::allocator>>) @ 0x000000001490e734 7. /build/src/Interpreters/InterpreterCreateQuery.cpp:383: DB::InterpreterCreateQuery::createDatabase(DB::ASTCreateQuery&) @ 0x00000000148e8e14 8. /build/src/Interpreters/InterpreterCreateQuery.cpp:2351: DB::InterpreterCreateQuery::execute() @ 0x0000000014905a3a 9. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88dc9 10. /build/src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x0000000014c8ca7b 11. /build/src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000001686da12 12. /build/src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x0000000016870807 13. /build/src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x0000000016907e99 14. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 15. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 16. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 17. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 18. ? @ 0x00007fbc6213eac3 19. ? @ 0x00007fbc621d0850 2025.07.28 11:51:00.283600 [ 7630 ] {f391729b-a057-431b-bdb4-0db656fb13ca} DynamicQueryHandler: Code: 253. DB::Exception: Replica r1 of shard s1 of replicated database at /test/db/test_8 already exists. Replica host ID: '146b4357c08d:9000:ee38db95-0be7-448e-98e5-40a61c7cf34b', current host ID: '146b4357c08d:9000:7517a04a-f7ca-4896-a159-3f9b90c5505e'. (REPLICA_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.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&) @ 0x0000000013db5399 4. /build/src/Databases/DatabaseReplicated.cpp:494: DB::DatabaseReplicated::tryConnectToZooKeeperAndInitDatabase(DB::LoadingStrictnessLevel) @ 0x0000000013d91155 5. /build/src/Databases/DatabaseReplicated.cpp:735: DB::DatabaseReplicated::beforeLoadingMetadata(std::shared_ptr, DB::LoadingStrictnessLevel) @ 0x0000000013d954d4 6. /build/src/Databases/TablesLoader.cpp:57: DB::TablesLoader::loadTablesAsync(std::unordered_set, std::hash>, std::equal_to>, std::allocator>>) @ 0x000000001490e734 7. /build/src/Interpreters/InterpreterCreateQuery.cpp:383: DB::InterpreterCreateQuery::createDatabase(DB::ASTCreateQuery&) @ 0x00000000148e8e14 8. /build/src/Interpreters/InterpreterCreateQuery.cpp:2351: DB::InterpreterCreateQuery::execute() @ 0x0000000014905a3a 9. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88dc9 10. /build/src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x0000000014c8ca7b 11. /build/src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000001686da12 12. /build/src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x0000000016870807 13. /build/src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x0000000016907e99 14. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 15. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 16. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 17. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 18. ? @ 0x00007fbc6213eac3 19. ? @ 0x00007fbc621d0850 (version 25.3.6.10636.altinitytest (altinity build)) 2025.07.28 11:51:00.441123 [ 6322 ] {94870f37-47b7-4676-ad0d-d9690400ce66} executeQuery: Code: 253. DB::Exception: Replica r1 of shard s1 of replicated database at /test/db/test_8 already exists. Replica host ID: '146b4357c08d:9000:ee38db95-0be7-448e-98e5-40a61c7cf34b', current host ID: '146b4357c08d:9000:56d35c15-0358-4c9f-9770-40f7adf79f6c'. (REPLICA_ALREADY_EXISTS) (version 25.3.6.10636.altinitytest (altinity build)) (from [::1]:50410) (comment: 01294_system_distributed_on_cluster.sql) (in query: CREATE DATABASE IF NOT EXISTS test_aw44u20v ENGINE=Replicated('/test/db/test_8', 's1', 'r1') ), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.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&) @ 0x0000000013db5399 4. /build/src/Databases/DatabaseReplicated.cpp:494: DB::DatabaseReplicated::tryConnectToZooKeeperAndInitDatabase(DB::LoadingStrictnessLevel) @ 0x0000000013d91155 5. /build/src/Databases/DatabaseReplicated.cpp:735: DB::DatabaseReplicated::beforeLoadingMetadata(std::shared_ptr, DB::LoadingStrictnessLevel) @ 0x0000000013d954d4 6. /build/src/Databases/TablesLoader.cpp:57: DB::TablesLoader::loadTablesAsync(std::unordered_set, std::hash>, std::equal_to>, std::allocator>>) @ 0x000000001490e734 7. /build/src/Interpreters/InterpreterCreateQuery.cpp:383: DB::InterpreterCreateQuery::createDatabase(DB::ASTCreateQuery&) @ 0x00000000148e8e14 8. /build/src/Interpreters/InterpreterCreateQuery.cpp:2351: DB::InterpreterCreateQuery::execute() @ 0x0000000014905a3a 9. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88dc9 10. /build/src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x0000000014c8ca7b 11. /build/src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000001686da12 12. /build/src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x0000000016870807 13. /build/src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x0000000016907e99 14. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 15. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 16. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 17. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 18. ? @ 0x00007fbc6213eac3 19. ? @ 0x00007fbc621d0850 2025.07.28 11:51:00.444567 [ 6322 ] {94870f37-47b7-4676-ad0d-d9690400ce66} DynamicQueryHandler: Code: 253. DB::Exception: Replica r1 of shard s1 of replicated database at /test/db/test_8 already exists. Replica host ID: '146b4357c08d:9000:ee38db95-0be7-448e-98e5-40a61c7cf34b', current host ID: '146b4357c08d:9000:56d35c15-0358-4c9f-9770-40f7adf79f6c'. (REPLICA_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.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&) @ 0x0000000013db5399 4. /build/src/Databases/DatabaseReplicated.cpp:494: DB::DatabaseReplicated::tryConnectToZooKeeperAndInitDatabase(DB::LoadingStrictnessLevel) @ 0x0000000013d91155 5. /build/src/Databases/DatabaseReplicated.cpp:735: DB::DatabaseReplicated::beforeLoadingMetadata(std::shared_ptr, DB::LoadingStrictnessLevel) @ 0x0000000013d954d4 6. /build/src/Databases/TablesLoader.cpp:57: DB::TablesLoader::loadTablesAsync(std::unordered_set, std::hash>, std::equal_to>, std::allocator>>) @ 0x000000001490e734 7. /build/src/Interpreters/InterpreterCreateQuery.cpp:383: DB::InterpreterCreateQuery::createDatabase(DB::ASTCreateQuery&) @ 0x00000000148e8e14 8. /build/src/Interpreters/InterpreterCreateQuery.cpp:2351: DB::InterpreterCreateQuery::execute() @ 0x0000000014905a3a 9. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88dc9 10. /build/src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x0000000014c8ca7b 11. /build/src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000001686da12 12. /build/src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x0000000016870807 13. /build/src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x0000000016907e99 14. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 15. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 16. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 17. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 18. ? @ 0x00007fbc6213eac3 19. ? @ 0x00007fbc621d0850 (version 25.3.6.10636.altinitytest (altinity build)) 2025.07.28 11:51:00.755200 [ 3287 ] {f8493b55-46af-4fcd-8836-55d1ac4af3b3} executeQuery: Code: 47. DB::Exception: Unknown expression or function identifier `x` in scope x = 1. Maybe you meant: ['a']. (UNKNOWN_IDENTIFIER) (version 25.3.6.10636.altinitytest (altinity build)) (from [::1]:58246) (comment: 02481_default_value_used_in_row_level_filter.sql) (query 5, line 9) (in query: -- { echoOn } SELECT a, c FROM test_rlp WHERE c%2 == 0 AND b < 5;), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.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&&) @ 0x000000001404b3b9 4. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3771: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000001401b849 5. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3980: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000014018e31 6. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:2925: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000001402fcbd 7. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3838: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000014019a9e 8. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:209: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000001401270e 9. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000014011fce 10. /build/src/Planner/Utils.cpp:458: DB::buildFilterInfo(std::shared_ptr, std::shared_ptr const&, std::shared_ptr&, std::unordered_set, std::equal_to, std::allocator>) @ 0x0000000013fe8bcf 11. /build/src/Planner/PlannerJoinTree.cpp:535: DB::(anonymous namespace)::buildQueryPlanForTableExpression(std::shared_ptr, std::shared_ptr const&, DB::SelectQueryInfo const&, DB::SelectQueryOptions const&, std::shared_ptr&, bool, bool) @ 0x00000000149956d3 12. /build/src/Planner/PlannerJoinTree.cpp:2252: DB::buildJoinTreeQueryPlan(std::shared_ptr const&, DB::SelectQueryInfo const&, DB::SelectQueryOptions&, std::unordered_set, std::equal_to, std::allocator> const&, std::shared_ptr&) @ 0x000000001498e109 13. /build/src/Planner/Planner.cpp:1553: DB::Planner::buildPlanForQueryNode() @ 0x0000000014979dae 14. /build/src/Planner/Planner.cpp:1308: DB::Planner::buildQueryPlanIfNeeded() @ 0x000000001497685c 15. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:255: DB::InterpreterSelectQueryAnalyzer::getQueryPlan() @ 0x000000001497476d 16. /build/src/Interpreters/executeQuery.cpp:1405: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88806 17. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 18. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 19. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 20. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 21. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 22. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 23. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 24. ? @ 0x00007fbc6213eac3 25. ? @ 0x00007fbc621d0850 2025.07.28 11:51:00.768148 [ 3287 ] {} TCPHandler: Code: 47. DB::Exception: Unknown expression or function identifier `x` in scope x = 1. Maybe you meant: ['a']. (UNKNOWN_IDENTIFIER), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.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&&) @ 0x000000001404b3b9 4. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3771: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000001401b849 5. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3980: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000014018e31 6. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:2925: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000001402fcbd 7. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3838: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000014019a9e 8. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:209: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000001401270e 9. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000014011fce 10. /build/src/Planner/Utils.cpp:458: DB::buildFilterInfo(std::shared_ptr, std::shared_ptr const&, std::shared_ptr&, std::unordered_set, std::equal_to, std::allocator>) @ 0x0000000013fe8bcf 11. /build/src/Planner/PlannerJoinTree.cpp:535: DB::(anonymous namespace)::buildQueryPlanForTableExpression(std::shared_ptr, std::shared_ptr const&, DB::SelectQueryInfo const&, DB::SelectQueryOptions const&, std::shared_ptr&, bool, bool) @ 0x00000000149956d3 12. /build/src/Planner/PlannerJoinTree.cpp:2252: DB::buildJoinTreeQueryPlan(std::shared_ptr const&, DB::SelectQueryInfo const&, DB::SelectQueryOptions&, std::unordered_set, std::equal_to, std::allocator> const&, std::shared_ptr&) @ 0x000000001498e109 13. /build/src/Planner/Planner.cpp:1553: DB::Planner::buildPlanForQueryNode() @ 0x0000000014979dae 14. /build/src/Planner/Planner.cpp:1308: DB::Planner::buildQueryPlanIfNeeded() @ 0x000000001497685c 15. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:255: DB::InterpreterSelectQueryAnalyzer::getQueryPlan() @ 0x000000001497476d 16. /build/src/Interpreters/executeQuery.cpp:1405: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88806 17. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 18. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 19. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 20. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 21. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 22. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 23. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 24. ? @ 0x00007fbc6213eac3 25. ? @ 0x00007fbc621d0850 2025.07.28 11:51:00.787185 [ 5951 ] {5f815970-0ab8-459e-9c17-c42de16cebb6} executeQuery: Code: 253. DB::Exception: Replica r1 of shard s1 of replicated database at /test/db/test_8 already exists. Replica host ID: '146b4357c08d:9000:ee38db95-0be7-448e-98e5-40a61c7cf34b', current host ID: '146b4357c08d:9000:e67eae00-03be-4ba4-abe2-f9c406de927e'. (REPLICA_ALREADY_EXISTS) (version 25.3.6.10636.altinitytest (altinity build)) (from [::1]:50414) (comment: 02705_capnp_more_types.sh) (in query: CREATE DATABASE IF NOT EXISTS test_2ptyqhws ENGINE=Replicated('/test/db/test_8', 's1', 'r1') ), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.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&) @ 0x0000000013db5399 4. /build/src/Databases/DatabaseReplicated.cpp:494: DB::DatabaseReplicated::tryConnectToZooKeeperAndInitDatabase(DB::LoadingStrictnessLevel) @ 0x0000000013d91155 5. /build/src/Databases/DatabaseReplicated.cpp:735: DB::DatabaseReplicated::beforeLoadingMetadata(std::shared_ptr, DB::LoadingStrictnessLevel) @ 0x0000000013d954d4 6. /build/src/Databases/TablesLoader.cpp:57: DB::TablesLoader::loadTablesAsync(std::unordered_set, std::hash>, std::equal_to>, std::allocator>>) @ 0x000000001490e734 7. /build/src/Interpreters/InterpreterCreateQuery.cpp:383: DB::InterpreterCreateQuery::createDatabase(DB::ASTCreateQuery&) @ 0x00000000148e8e14 8. /build/src/Interpreters/InterpreterCreateQuery.cpp:2351: DB::InterpreterCreateQuery::execute() @ 0x0000000014905a3a 9. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88dc9 10. /build/src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x0000000014c8ca7b 11. /build/src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000001686da12 12. /build/src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x0000000016870807 13. /build/src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x0000000016907e99 14. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 15. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 16. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 17. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 18. ? @ 0x00007fbc6213eac3 19. ? @ 0x00007fbc621d0850 2025.07.28 11:51:00.790877 [ 5951 ] {5f815970-0ab8-459e-9c17-c42de16cebb6} DynamicQueryHandler: Code: 253. DB::Exception: Replica r1 of shard s1 of replicated database at /test/db/test_8 already exists. Replica host ID: '146b4357c08d:9000:ee38db95-0be7-448e-98e5-40a61c7cf34b', current host ID: '146b4357c08d:9000:e67eae00-03be-4ba4-abe2-f9c406de927e'. (REPLICA_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.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&) @ 0x0000000013db5399 4. /build/src/Databases/DatabaseReplicated.cpp:494: DB::DatabaseReplicated::tryConnectToZooKeeperAndInitDatabase(DB::LoadingStrictnessLevel) @ 0x0000000013d91155 5. /build/src/Databases/DatabaseReplicated.cpp:735: DB::DatabaseReplicated::beforeLoadingMetadata(std::shared_ptr, DB::LoadingStrictnessLevel) @ 0x0000000013d954d4 6. /build/src/Databases/TablesLoader.cpp:57: DB::TablesLoader::loadTablesAsync(std::unordered_set, std::hash>, std::equal_to>, std::allocator>>) @ 0x000000001490e734 7. /build/src/Interpreters/InterpreterCreateQuery.cpp:383: DB::InterpreterCreateQuery::createDatabase(DB::ASTCreateQuery&) @ 0x00000000148e8e14 8. /build/src/Interpreters/InterpreterCreateQuery.cpp:2351: DB::InterpreterCreateQuery::execute() @ 0x0000000014905a3a 9. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88dc9 10. /build/src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x0000000014c8ca7b 11. /build/src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000001686da12 12. /build/src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x0000000016870807 13. /build/src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x0000000016907e99 14. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 15. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 16. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 17. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 18. ? @ 0x00007fbc6213eac3 19. ? @ 0x00007fbc621d0850 (version 25.3.6.10636.altinitytest (altinity build)) 2025.07.28 11:51:00.936016 [ 3285 ] {76a09260-1e71-4754-935c-966ea21541f9} executeQuery: Code: 439. DB::Exception: Cannot schedule a task: failed to start the thread (threads=0, jobs=0). (CANNOT_SCHEDULE_TASK) (version 25.3.6.10636.altinitytest (altinity build)) (from [::1]:50434) (comment: 02995_preliminary_filters_duplicated_columns.sql) (in query: DROP DATABASE IF EXISTS test_bwprukie SYNC ), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000fccaeeb 4. /build/src/Common/ThreadPool.cpp:275: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000fccc813 5. /build/src/Common/ThreadPool.cpp:308: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fcc8286 6. /build/src/Common/ThreadPool.cpp:494: ThreadPoolImpl>::scheduleOrThrowOnError(std::function, Priority) @ 0x000000000fcc7a0e 7. /build/src/Common/threadPoolCallbackRunner.h:188: DB::ThreadPoolCallbackRunnerLocal>, std::function>::operator()(std::function&&, Priority, std::optional) @ 0x00000000119df78e 8. /build/src/Interpreters/InterpreterDropQuery.cpp:448: DB::InterpreterDropQuery::executeToDatabaseImpl(DB::ASTDropQuery const&, std::shared_ptr&, std::vector, DB::UUIDTag>, std::allocator, DB::UUIDTag>>>&) @ 0x00000000149175a2 9. /build/src/Interpreters/InterpreterDropQuery.cpp:363: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x0000000014913988 10. /build/src/Interpreters/InterpreterDropQuery.cpp:99: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000014913142 11. /build/src/Interpreters/InterpreterDropQuery.cpp:72: DB::InterpreterDropQuery::execute() @ 0x0000000014912b65 12. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88dc9 13. /build/src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x0000000014c8ca7b 14. /build/src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000001686da12 15. /build/src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x0000000016870807 16. /build/src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x0000000016907e99 17. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 18. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 19. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 20. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 21. ? @ 0x00007fbc6213eac3 22. ? @ 0x00007fbc621d0850 2025.07.28 11:51:00.946915 [ 3285 ] {76a09260-1e71-4754-935c-966ea21541f9} DynamicQueryHandler: 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. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000fccaeeb 4. /build/src/Common/ThreadPool.cpp:275: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000fccc813 5. /build/src/Common/ThreadPool.cpp:308: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fcc8286 6. /build/src/Common/ThreadPool.cpp:494: ThreadPoolImpl>::scheduleOrThrowOnError(std::function, Priority) @ 0x000000000fcc7a0e 7. /build/src/Common/threadPoolCallbackRunner.h:188: DB::ThreadPoolCallbackRunnerLocal>, std::function>::operator()(std::function&&, Priority, std::optional) @ 0x00000000119df78e 8. /build/src/Interpreters/InterpreterDropQuery.cpp:448: DB::InterpreterDropQuery::executeToDatabaseImpl(DB::ASTDropQuery const&, std::shared_ptr&, std::vector, DB::UUIDTag>, std::allocator, DB::UUIDTag>>>&) @ 0x00000000149175a2 9. /build/src/Interpreters/InterpreterDropQuery.cpp:363: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x0000000014913988 10. /build/src/Interpreters/InterpreterDropQuery.cpp:99: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000014913142 11. /build/src/Interpreters/InterpreterDropQuery.cpp:72: DB::InterpreterDropQuery::execute() @ 0x0000000014912b65 12. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88dc9 13. /build/src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x0000000014c8ca7b 14. /build/src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000001686da12 15. /build/src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x0000000016870807 16. /build/src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x0000000016907e99 17. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 18. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 19. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 20. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 21. ? @ 0x00007fbc6213eac3 22. ? @ 0x00007fbc621d0850 (version 25.3.6.10636.altinitytest (altinity build)) 2025.07.28 11:51:00.994728 [ 4900 ] {d82d27c5-e534-4c08-b41f-51178a133e19} executeQuery: Code: 57. DB::Exception: Table test_9.test_02152 already exists. (TABLE_ALREADY_EXISTS) (version 25.3.6.10636.altinitytest (altinity build)) (from [::1]:58292) (comment: 02152_csv_tuple.sql) (query 6, line 7) (in query: create table test_02152 (x UInt32, y String, z Array(UInt32), t Tuple(UInt32, String, Array(UInt32))) engine=File('CustomSeparated') settings format_custom_field_delimiter='', format_custom_row_before_delimiter='', format_custom_row_after_delimiter='', format_custom_escaping_rule='CSV';), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000a06a8eb 4. /build/src/Interpreters/InterpreterCreateQuery.cpp:1824: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x0000000014901d53 5. /build/src/Interpreters/InterpreterCreateQuery.cpp:1743: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000148f9aa9 6. /build/src/Interpreters/InterpreterCreateQuery.cpp:2352: DB::InterpreterCreateQuery::execute() @ 0x0000000014905a41 7. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88dc9 8. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 9. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 10. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 11. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 12. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 13. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 14. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 15. ? @ 0x00007fbc6213eac3 16. ? @ 0x00007fbc621d0850 2025.07.28 11:51:01.021690 [ 4900 ] {} TCPHandler: Code: 57. DB::Exception: Table test_9.test_02152 already exists. (TABLE_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000a06a8eb 4. /build/src/Interpreters/InterpreterCreateQuery.cpp:1824: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x0000000014901d53 5. /build/src/Interpreters/InterpreterCreateQuery.cpp:1743: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000148f9aa9 6. /build/src/Interpreters/InterpreterCreateQuery.cpp:2352: DB::InterpreterCreateQuery::execute() @ 0x0000000014905a41 7. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88dc9 8. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 9. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 10. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 11. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 12. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 13. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 14. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 15. ? @ 0x00007fbc6213eac3 16. ? @ 0x00007fbc621d0850 2025.07.28 11:51:01.026291 [ 3287 ] {2fa5c77c-df30-49bc-82f7-56a104178b1e} executeQuery: Code: 253. DB::Exception: Replica r1 of shard s1 of replicated database at /test/db/test_8 already exists. Replica host ID: '146b4357c08d:9000:ee38db95-0be7-448e-98e5-40a61c7cf34b', current host ID: '146b4357c08d:9000:1550db23-f744-4f16-8503-fa39949efacd'. (REPLICA_ALREADY_EXISTS) (version 25.3.6.10636.altinitytest (altinity build)) (from [::1]:50430) (comment: 00158_cache_dictionary_has.sql) (in query: CREATE DATABASE IF NOT EXISTS test_c315call ENGINE=Replicated('/test/db/test_8', 's1', 'r1') ), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.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&) @ 0x0000000013db5399 4. /build/src/Databases/DatabaseReplicated.cpp:494: DB::DatabaseReplicated::tryConnectToZooKeeperAndInitDatabase(DB::LoadingStrictnessLevel) @ 0x0000000013d91155 5. /build/src/Databases/DatabaseReplicated.cpp:735: DB::DatabaseReplicated::beforeLoadingMetadata(std::shared_ptr, DB::LoadingStrictnessLevel) @ 0x0000000013d954d4 6. /build/src/Databases/TablesLoader.cpp:57: DB::TablesLoader::loadTablesAsync(std::unordered_set, std::hash>, std::equal_to>, std::allocator>>) @ 0x000000001490e734 7. /build/src/Interpreters/InterpreterCreateQuery.cpp:383: DB::InterpreterCreateQuery::createDatabase(DB::ASTCreateQuery&) @ 0x00000000148e8e14 8. /build/src/Interpreters/InterpreterCreateQuery.cpp:2351: DB::InterpreterCreateQuery::execute() @ 0x0000000014905a3a 9. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88dc9 10. /build/src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x0000000014c8ca7b 11. /build/src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000001686da12 12. /build/src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x0000000016870807 13. /build/src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x0000000016907e99 14. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 15. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 16. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 17. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 18. ? @ 0x00007fbc6213eac3 19. ? @ 0x00007fbc621d0850 2025.07.28 11:51:01.032313 [ 3287 ] {2fa5c77c-df30-49bc-82f7-56a104178b1e} DynamicQueryHandler: Code: 253. DB::Exception: Replica r1 of shard s1 of replicated database at /test/db/test_8 already exists. Replica host ID: '146b4357c08d:9000:ee38db95-0be7-448e-98e5-40a61c7cf34b', current host ID: '146b4357c08d:9000:1550db23-f744-4f16-8503-fa39949efacd'. (REPLICA_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.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&) @ 0x0000000013db5399 4. /build/src/Databases/DatabaseReplicated.cpp:494: DB::DatabaseReplicated::tryConnectToZooKeeperAndInitDatabase(DB::LoadingStrictnessLevel) @ 0x0000000013d91155 5. /build/src/Databases/DatabaseReplicated.cpp:735: DB::DatabaseReplicated::beforeLoadingMetadata(std::shared_ptr, DB::LoadingStrictnessLevel) @ 0x0000000013d954d4 6. /build/src/Databases/TablesLoader.cpp:57: DB::TablesLoader::loadTablesAsync(std::unordered_set, std::hash>, std::equal_to>, std::allocator>>) @ 0x000000001490e734 7. /build/src/Interpreters/InterpreterCreateQuery.cpp:383: DB::InterpreterCreateQuery::createDatabase(DB::ASTCreateQuery&) @ 0x00000000148e8e14 8. /build/src/Interpreters/InterpreterCreateQuery.cpp:2351: DB::InterpreterCreateQuery::execute() @ 0x0000000014905a3a 9. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88dc9 10. /build/src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x0000000014c8ca7b 11. /build/src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000001686da12 12. /build/src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x0000000016870807 13. /build/src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x0000000016907e99 14. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 15. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 16. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 17. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 18. ? @ 0x00007fbc6213eac3 19. ? @ 0x00007fbc621d0850 (version 25.3.6.10636.altinitytest (altinity build)) 2025.07.28 11:51:01.278227 [ 6322 ] {3e2725ac-e9b0-417d-a29f-477dc20069a8} executeQuery: Code: 253. DB::Exception: Replica r1 of shard s1 of replicated database at /test/db/test_8 already exists. Replica host ID: '146b4357c08d:9000:ee38db95-0be7-448e-98e5-40a61c7cf34b', current host ID: '146b4357c08d:9000:5793d4c9-9c6c-4842-a7e1-c90ff7708e72'. (REPLICA_ALREADY_EXISTS) (version 25.3.6.10636.altinitytest (altinity build)) (from [::1]:50462) (comment: 01778_hierarchical_dictionaries.sql) (in query: CREATE DATABASE IF NOT EXISTS test_2onl7wh1 ENGINE=Replicated('/test/db/test_8', 's1', 'r1') ), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.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&) @ 0x0000000013db5399 4. /build/src/Databases/DatabaseReplicated.cpp:494: DB::DatabaseReplicated::tryConnectToZooKeeperAndInitDatabase(DB::LoadingStrictnessLevel) @ 0x0000000013d91155 5. /build/src/Databases/DatabaseReplicated.cpp:735: DB::DatabaseReplicated::beforeLoadingMetadata(std::shared_ptr, DB::LoadingStrictnessLevel) @ 0x0000000013d954d4 6. /build/src/Databases/TablesLoader.cpp:57: DB::TablesLoader::loadTablesAsync(std::unordered_set, std::hash>, std::equal_to>, std::allocator>>) @ 0x000000001490e734 7. /build/src/Interpreters/InterpreterCreateQuery.cpp:383: DB::InterpreterCreateQuery::createDatabase(DB::ASTCreateQuery&) @ 0x00000000148e8e14 8. /build/src/Interpreters/InterpreterCreateQuery.cpp:2351: DB::InterpreterCreateQuery::execute() @ 0x0000000014905a3a 9. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88dc9 10. /build/src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x0000000014c8ca7b 11. /build/src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000001686da12 12. /build/src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x0000000016870807 13. /build/src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x0000000016907e99 14. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 15. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 16. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 17. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 18. ? @ 0x00007fbc6213eac3 19. ? @ 0x00007fbc621d0850 2025.07.28 11:51:01.296135 [ 6322 ] {3e2725ac-e9b0-417d-a29f-477dc20069a8} DynamicQueryHandler: Code: 253. DB::Exception: Replica r1 of shard s1 of replicated database at /test/db/test_8 already exists. Replica host ID: '146b4357c08d:9000:ee38db95-0be7-448e-98e5-40a61c7cf34b', current host ID: '146b4357c08d:9000:5793d4c9-9c6c-4842-a7e1-c90ff7708e72'. (REPLICA_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.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&) @ 0x0000000013db5399 4. /build/src/Databases/DatabaseReplicated.cpp:494: DB::DatabaseReplicated::tryConnectToZooKeeperAndInitDatabase(DB::LoadingStrictnessLevel) @ 0x0000000013d91155 5. /build/src/Databases/DatabaseReplicated.cpp:735: DB::DatabaseReplicated::beforeLoadingMetadata(std::shared_ptr, DB::LoadingStrictnessLevel) @ 0x0000000013d954d4 6. /build/src/Databases/TablesLoader.cpp:57: DB::TablesLoader::loadTablesAsync(std::unordered_set, std::hash>, std::equal_to>, std::allocator>>) @ 0x000000001490e734 7. /build/src/Interpreters/InterpreterCreateQuery.cpp:383: DB::InterpreterCreateQuery::createDatabase(DB::ASTCreateQuery&) @ 0x00000000148e8e14 8. /build/src/Interpreters/InterpreterCreateQuery.cpp:2351: DB::InterpreterCreateQuery::execute() @ 0x0000000014905a3a 9. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88dc9 10. /build/src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x0000000014c8ca7b 11. /build/src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000001686da12 12. /build/src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x0000000016870807 13. /build/src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x0000000016907e99 14. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 15. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 16. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 17. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 18. ? @ 0x00007fbc6213eac3 19. ? @ 0x00007fbc621d0850 (version 25.3.6.10636.altinitytest (altinity build)) 2025.07.28 11:51:01.426103 [ 3285 ] {9f167b80-3108-46bb-829a-10dc99c1e406} executeQuery: Code: 253. DB::Exception: Replica r1 of shard s1 of replicated database at /test/db/test_8 already exists. Replica host ID: '146b4357c08d:9000:ee38db95-0be7-448e-98e5-40a61c7cf34b', current host ID: '146b4357c08d:9000:e84e2378-b1fb-4223-8d53-17fc2f740bd5'. (REPLICA_ALREADY_EXISTS) (version 25.3.6.10636.altinitytest (altinity build)) (from [::1]:38044) (comment: 02503_cache_on_write_with_small_segment_size.sh) (in query: CREATE DATABASE IF NOT EXISTS test_sdl16fen ENGINE=Replicated('/test/db/test_8', 's1', 'r1') ), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.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&) @ 0x0000000013db5399 4. /build/src/Databases/DatabaseReplicated.cpp:494: DB::DatabaseReplicated::tryConnectToZooKeeperAndInitDatabase(DB::LoadingStrictnessLevel) @ 0x0000000013d91155 5. /build/src/Databases/DatabaseReplicated.cpp:735: DB::DatabaseReplicated::beforeLoadingMetadata(std::shared_ptr, DB::LoadingStrictnessLevel) @ 0x0000000013d954d4 6. /build/src/Databases/TablesLoader.cpp:57: DB::TablesLoader::loadTablesAsync(std::unordered_set, std::hash>, std::equal_to>, std::allocator>>) @ 0x000000001490e734 7. /build/src/Interpreters/InterpreterCreateQuery.cpp:383: DB::InterpreterCreateQuery::createDatabase(DB::ASTCreateQuery&) @ 0x00000000148e8e14 8. /build/src/Interpreters/InterpreterCreateQuery.cpp:2351: DB::InterpreterCreateQuery::execute() @ 0x0000000014905a3a 9. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88dc9 10. /build/src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x0000000014c8ca7b 11. /build/src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000001686da12 12. /build/src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x0000000016870807 13. /build/src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x0000000016907e99 14. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 15. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 16. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 17. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 18. ? @ 0x00007fbc6213eac3 19. ? @ 0x00007fbc621d0850 2025.07.28 11:51:01.428099 [ 3285 ] {9f167b80-3108-46bb-829a-10dc99c1e406} DynamicQueryHandler: Code: 253. DB::Exception: Replica r1 of shard s1 of replicated database at /test/db/test_8 already exists. Replica host ID: '146b4357c08d:9000:ee38db95-0be7-448e-98e5-40a61c7cf34b', current host ID: '146b4357c08d:9000:e84e2378-b1fb-4223-8d53-17fc2f740bd5'. (REPLICA_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.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&) @ 0x0000000013db5399 4. /build/src/Databases/DatabaseReplicated.cpp:494: DB::DatabaseReplicated::tryConnectToZooKeeperAndInitDatabase(DB::LoadingStrictnessLevel) @ 0x0000000013d91155 5. /build/src/Databases/DatabaseReplicated.cpp:735: DB::DatabaseReplicated::beforeLoadingMetadata(std::shared_ptr, DB::LoadingStrictnessLevel) @ 0x0000000013d954d4 6. /build/src/Databases/TablesLoader.cpp:57: DB::TablesLoader::loadTablesAsync(std::unordered_set, std::hash>, std::equal_to>, std::allocator>>) @ 0x000000001490e734 7. /build/src/Interpreters/InterpreterCreateQuery.cpp:383: DB::InterpreterCreateQuery::createDatabase(DB::ASTCreateQuery&) @ 0x00000000148e8e14 8. /build/src/Interpreters/InterpreterCreateQuery.cpp:2351: DB::InterpreterCreateQuery::execute() @ 0x0000000014905a3a 9. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88dc9 10. /build/src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x0000000014c8ca7b 11. /build/src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000001686da12 12. /build/src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x0000000016870807 13. /build/src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x0000000016907e99 14. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 15. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 16. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 17. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 18. ? @ 0x00007fbc6213eac3 19. ? @ 0x00007fbc621d0850 (version 25.3.6.10636.altinitytest (altinity build)) 2025.07.28 11:51:01.671994 [ 5327 ] {8111918e-3656-452b-9fe0-09c8a9197b5d} executeQuery: Code: 253. DB::Exception: Replica r1 of shard s1 of replicated database at /test/db/test_8 already exists. Replica host ID: '146b4357c08d:9000:ee38db95-0be7-448e-98e5-40a61c7cf34b', current host ID: '146b4357c08d:9000:646835d1-fe8d-4e1d-b6ef-1bcbc3838377'. (REPLICA_ALREADY_EXISTS) (version 25.3.6.10636.altinitytest (altinity build)) (from [::1]:38048) (comment: 03164_orc_signedness.sql) (in query: CREATE DATABASE IF NOT EXISTS test_lvtsdg2c ENGINE=Replicated('/test/db/test_8', 's1', 'r1') ), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.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&) @ 0x0000000013db5399 4. /build/src/Databases/DatabaseReplicated.cpp:494: DB::DatabaseReplicated::tryConnectToZooKeeperAndInitDatabase(DB::LoadingStrictnessLevel) @ 0x0000000013d91155 5. /build/src/Databases/DatabaseReplicated.cpp:735: DB::DatabaseReplicated::beforeLoadingMetadata(std::shared_ptr, DB::LoadingStrictnessLevel) @ 0x0000000013d954d4 6. /build/src/Databases/TablesLoader.cpp:57: DB::TablesLoader::loadTablesAsync(std::unordered_set, std::hash>, std::equal_to>, std::allocator>>) @ 0x000000001490e734 7. /build/src/Interpreters/InterpreterCreateQuery.cpp:383: DB::InterpreterCreateQuery::createDatabase(DB::ASTCreateQuery&) @ 0x00000000148e8e14 8. /build/src/Interpreters/InterpreterCreateQuery.cpp:2351: DB::InterpreterCreateQuery::execute() @ 0x0000000014905a3a 9. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88dc9 10. /build/src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x0000000014c8ca7b 11. /build/src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000001686da12 12. /build/src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x0000000016870807 13. /build/src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x0000000016907e99 14. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 15. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 16. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 17. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 18. ? @ 0x00007fbc6213eac3 19. ? @ 0x00007fbc621d0850 2025.07.28 11:51:01.673719 [ 5327 ] {8111918e-3656-452b-9fe0-09c8a9197b5d} DynamicQueryHandler: Code: 253. DB::Exception: Replica r1 of shard s1 of replicated database at /test/db/test_8 already exists. Replica host ID: '146b4357c08d:9000:ee38db95-0be7-448e-98e5-40a61c7cf34b', current host ID: '146b4357c08d:9000:646835d1-fe8d-4e1d-b6ef-1bcbc3838377'. (REPLICA_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.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&) @ 0x0000000013db5399 4. /build/src/Databases/DatabaseReplicated.cpp:494: DB::DatabaseReplicated::tryConnectToZooKeeperAndInitDatabase(DB::LoadingStrictnessLevel) @ 0x0000000013d91155 5. /build/src/Databases/DatabaseReplicated.cpp:735: DB::DatabaseReplicated::beforeLoadingMetadata(std::shared_ptr, DB::LoadingStrictnessLevel) @ 0x0000000013d954d4 6. /build/src/Databases/TablesLoader.cpp:57: DB::TablesLoader::loadTablesAsync(std::unordered_set, std::hash>, std::equal_to>, std::allocator>>) @ 0x000000001490e734 7. /build/src/Interpreters/InterpreterCreateQuery.cpp:383: DB::InterpreterCreateQuery::createDatabase(DB::ASTCreateQuery&) @ 0x00000000148e8e14 8. /build/src/Interpreters/InterpreterCreateQuery.cpp:2351: DB::InterpreterCreateQuery::execute() @ 0x0000000014905a3a 9. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88dc9 10. /build/src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x0000000014c8ca7b 11. /build/src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000001686da12 12. /build/src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x0000000016870807 13. /build/src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x0000000016907e99 14. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 15. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 16. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 17. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 18. ? @ 0x00007fbc6213eac3 19. ? @ 0x00007fbc621d0850 (version 25.3.6.10636.altinitytest (altinity build)) 2025.07.28 11:51:01.769205 [ 4900 ] {5a6ed53c-e3b8-4651-94b4-482ed9b9d69c} executeQuery: Code: 253. DB::Exception: Replica r1 of shard s1 of replicated database at /test/db/test_8 already exists. Replica host ID: '146b4357c08d:9000:ee38db95-0be7-448e-98e5-40a61c7cf34b', current host ID: '146b4357c08d:9000:4a33fb18-7373-4083-b74e-7f4d4fa00e55'. (REPLICA_ALREADY_EXISTS) (version 25.3.6.10636.altinitytest (altinity build)) (from [::1]:38060) (comment: 03254_test_alter_user_no_changes.sql) (in query: CREATE DATABASE IF NOT EXISTS test_qrunk73f ENGINE=Replicated('/test/db/test_8', 's1', 'r1') ), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.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&) @ 0x0000000013db5399 4. /build/src/Databases/DatabaseReplicated.cpp:494: DB::DatabaseReplicated::tryConnectToZooKeeperAndInitDatabase(DB::LoadingStrictnessLevel) @ 0x0000000013d91155 5. /build/src/Databases/DatabaseReplicated.cpp:735: DB::DatabaseReplicated::beforeLoadingMetadata(std::shared_ptr, DB::LoadingStrictnessLevel) @ 0x0000000013d954d4 6. /build/src/Databases/TablesLoader.cpp:57: DB::TablesLoader::loadTablesAsync(std::unordered_set, std::hash>, std::equal_to>, std::allocator>>) @ 0x000000001490e734 7. /build/src/Interpreters/InterpreterCreateQuery.cpp:383: DB::InterpreterCreateQuery::createDatabase(DB::ASTCreateQuery&) @ 0x00000000148e8e14 8. /build/src/Interpreters/InterpreterCreateQuery.cpp:2351: DB::InterpreterCreateQuery::execute() @ 0x0000000014905a3a 9. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88dc9 10. /build/src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x0000000014c8ca7b 11. /build/src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000001686da12 12. /build/src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x0000000016870807 13. /build/src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x0000000016907e99 14. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 15. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 16. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 17. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 18. ? @ 0x00007fbc6213eac3 19. ? @ 0x00007fbc621d0850 2025.07.28 11:51:01.780495 [ 4900 ] {5a6ed53c-e3b8-4651-94b4-482ed9b9d69c} DynamicQueryHandler: Code: 253. DB::Exception: Replica r1 of shard s1 of replicated database at /test/db/test_8 already exists. Replica host ID: '146b4357c08d:9000:ee38db95-0be7-448e-98e5-40a61c7cf34b', current host ID: '146b4357c08d:9000:4a33fb18-7373-4083-b74e-7f4d4fa00e55'. (REPLICA_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.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&) @ 0x0000000013db5399 4. /build/src/Databases/DatabaseReplicated.cpp:494: DB::DatabaseReplicated::tryConnectToZooKeeperAndInitDatabase(DB::LoadingStrictnessLevel) @ 0x0000000013d91155 5. /build/src/Databases/DatabaseReplicated.cpp:735: DB::DatabaseReplicated::beforeLoadingMetadata(std::shared_ptr, DB::LoadingStrictnessLevel) @ 0x0000000013d954d4 6. /build/src/Databases/TablesLoader.cpp:57: DB::TablesLoader::loadTablesAsync(std::unordered_set, std::hash>, std::equal_to>, std::allocator>>) @ 0x000000001490e734 7. /build/src/Interpreters/InterpreterCreateQuery.cpp:383: DB::InterpreterCreateQuery::createDatabase(DB::ASTCreateQuery&) @ 0x00000000148e8e14 8. /build/src/Interpreters/InterpreterCreateQuery.cpp:2351: DB::InterpreterCreateQuery::execute() @ 0x0000000014905a3a 9. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88dc9 10. /build/src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x0000000014c8ca7b 11. /build/src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000001686da12 12. /build/src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x0000000016870807 13. /build/src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x0000000016907e99 14. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 15. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 16. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 17. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 18. ? @ 0x00007fbc6213eac3 19. ? @ 0x00007fbc621d0850 (version 25.3.6.10636.altinitytest (altinity build)) 2025.07.28 11:51:01.910460 [ 5327 ] {4a7d2177-3f4b-4d92-9ae7-9b9071b11bbf} executeQuery: Code: 253. DB::Exception: Replica r1 of shard s1 of replicated database at /test/db/test_8 already exists. Replica host ID: '146b4357c08d:9000:ee38db95-0be7-448e-98e5-40a61c7cf34b', current host ID: '146b4357c08d:9000:2321e095-b975-4eac-86d7-d8f1aea11d5c'. (REPLICA_ALREADY_EXISTS) (version 25.3.6.10636.altinitytest (altinity build)) (from [::1]:38070) (comment: 02483_check_virtuals_shile_using_structure_from_insertion_table.sql) (in query: CREATE DATABASE IF NOT EXISTS test_8ao2l7ps ENGINE=Replicated('/test/db/test_8', 's1', 'r1') ), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.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&) @ 0x0000000013db5399 4. /build/src/Databases/DatabaseReplicated.cpp:494: DB::DatabaseReplicated::tryConnectToZooKeeperAndInitDatabase(DB::LoadingStrictnessLevel) @ 0x0000000013d91155 5. /build/src/Databases/DatabaseReplicated.cpp:735: DB::DatabaseReplicated::beforeLoadingMetadata(std::shared_ptr, DB::LoadingStrictnessLevel) @ 0x0000000013d954d4 6. /build/src/Databases/TablesLoader.cpp:57: DB::TablesLoader::loadTablesAsync(std::unordered_set, std::hash>, std::equal_to>, std::allocator>>) @ 0x000000001490e734 7. /build/src/Interpreters/InterpreterCreateQuery.cpp:383: DB::InterpreterCreateQuery::createDatabase(DB::ASTCreateQuery&) @ 0x00000000148e8e14 8. /build/src/Interpreters/InterpreterCreateQuery.cpp:2351: DB::InterpreterCreateQuery::execute() @ 0x0000000014905a3a 9. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88dc9 10. /build/src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x0000000014c8ca7b 11. /build/src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000001686da12 12. /build/src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x0000000016870807 13. /build/src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x0000000016907e99 14. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 15. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 16. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 17. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 18. ? @ 0x00007fbc6213eac3 19. ? @ 0x00007fbc621d0850 2025.07.28 11:51:01.918035 [ 5327 ] {4a7d2177-3f4b-4d92-9ae7-9b9071b11bbf} DynamicQueryHandler: Code: 253. DB::Exception: Replica r1 of shard s1 of replicated database at /test/db/test_8 already exists. Replica host ID: '146b4357c08d:9000:ee38db95-0be7-448e-98e5-40a61c7cf34b', current host ID: '146b4357c08d:9000:2321e095-b975-4eac-86d7-d8f1aea11d5c'. (REPLICA_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.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&) @ 0x0000000013db5399 4. /build/src/Databases/DatabaseReplicated.cpp:494: DB::DatabaseReplicated::tryConnectToZooKeeperAndInitDatabase(DB::LoadingStrictnessLevel) @ 0x0000000013d91155 5. /build/src/Databases/DatabaseReplicated.cpp:735: DB::DatabaseReplicated::beforeLoadingMetadata(std::shared_ptr, DB::LoadingStrictnessLevel) @ 0x0000000013d954d4 6. /build/src/Databases/TablesLoader.cpp:57: DB::TablesLoader::loadTablesAsync(std::unordered_set, std::hash>, std::equal_to>, std::allocator>>) @ 0x000000001490e734 7. /build/src/Interpreters/InterpreterCreateQuery.cpp:383: DB::InterpreterCreateQuery::createDatabase(DB::ASTCreateQuery&) @ 0x00000000148e8e14 8. /build/src/Interpreters/InterpreterCreateQuery.cpp:2351: DB::InterpreterCreateQuery::execute() @ 0x0000000014905a3a 9. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88dc9 10. /build/src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x0000000014c8ca7b 11. /build/src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000001686da12 12. /build/src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x0000000016870807 13. /build/src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x0000000016907e99 14. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 15. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 16. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 17. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 18. ? @ 0x00007fbc6213eac3 19. ? @ 0x00007fbc621d0850 (version 25.3.6.10636.altinitytest (altinity build)) 2025.07.28 11:51:02.155613 [ 3287 ] {d74ae9b6-bf86-4192-8434-ad05a5010499} executeQuery: Code: 253. DB::Exception: Replica r1 of shard s1 of replicated database at /test/db/test_8 already exists. Replica host ID: '146b4357c08d:9000:ee38db95-0be7-448e-98e5-40a61c7cf34b', current host ID: '146b4357c08d:9000:f5797fc7-ec85-409c-9ebb-5c6e3f3275b2'. (REPLICA_ALREADY_EXISTS) (version 25.3.6.10636.altinitytest (altinity build)) (from [::1]:38080) (comment: 00053_replicate_segfault.sql) (in query: CREATE DATABASE IF NOT EXISTS test_ci533ldg ENGINE=Replicated('/test/db/test_8', 's1', 'r1') ), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.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&) @ 0x0000000013db5399 4. /build/src/Databases/DatabaseReplicated.cpp:494: DB::DatabaseReplicated::tryConnectToZooKeeperAndInitDatabase(DB::LoadingStrictnessLevel) @ 0x0000000013d91155 5. /build/src/Databases/DatabaseReplicated.cpp:735: DB::DatabaseReplicated::beforeLoadingMetadata(std::shared_ptr, DB::LoadingStrictnessLevel) @ 0x0000000013d954d4 6. /build/src/Databases/TablesLoader.cpp:57: DB::TablesLoader::loadTablesAsync(std::unordered_set, std::hash>, std::equal_to>, std::allocator>>) @ 0x000000001490e734 7. /build/src/Interpreters/InterpreterCreateQuery.cpp:383: DB::InterpreterCreateQuery::createDatabase(DB::ASTCreateQuery&) @ 0x00000000148e8e14 8. /build/src/Interpreters/InterpreterCreateQuery.cpp:2351: DB::InterpreterCreateQuery::execute() @ 0x0000000014905a3a 9. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88dc9 10. /build/src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x0000000014c8ca7b 11. /build/src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000001686da12 12. /build/src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x0000000016870807 13. /build/src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x0000000016907e99 14. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 15. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 16. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 17. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 18. ? @ 0x00007fbc6213eac3 19. ? @ 0x00007fbc621d0850 2025.07.28 11:51:02.185317 [ 3287 ] {d74ae9b6-bf86-4192-8434-ad05a5010499} DynamicQueryHandler: Code: 253. DB::Exception: Replica r1 of shard s1 of replicated database at /test/db/test_8 already exists. Replica host ID: '146b4357c08d:9000:ee38db95-0be7-448e-98e5-40a61c7cf34b', current host ID: '146b4357c08d:9000:f5797fc7-ec85-409c-9ebb-5c6e3f3275b2'. (REPLICA_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.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&) @ 0x0000000013db5399 4. /build/src/Databases/DatabaseReplicated.cpp:494: DB::DatabaseReplicated::tryConnectToZooKeeperAndInitDatabase(DB::LoadingStrictnessLevel) @ 0x0000000013d91155 5. /build/src/Databases/DatabaseReplicated.cpp:735: DB::DatabaseReplicated::beforeLoadingMetadata(std::shared_ptr, DB::LoadingStrictnessLevel) @ 0x0000000013d954d4 6. /build/src/Databases/TablesLoader.cpp:57: DB::TablesLoader::loadTablesAsync(std::unordered_set, std::hash>, std::equal_to>, std::allocator>>) @ 0x000000001490e734 7. /build/src/Interpreters/InterpreterCreateQuery.cpp:383: DB::InterpreterCreateQuery::createDatabase(DB::ASTCreateQuery&) @ 0x00000000148e8e14 8. /build/src/Interpreters/InterpreterCreateQuery.cpp:2351: DB::InterpreterCreateQuery::execute() @ 0x0000000014905a3a 9. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88dc9 10. /build/src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x0000000014c8ca7b 11. /build/src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000001686da12 12. /build/src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x0000000016870807 13. /build/src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x0000000016907e99 14. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 15. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 16. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 17. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 18. ? @ 0x00007fbc6213eac3 19. ? @ 0x00007fbc621d0850 (version 25.3.6.10636.altinitytest (altinity build)) 2025.07.28 11:51:02.393943 [ 3285 ] {27564c41-362f-4f8a-b00b-ba369b6ad3fe} executeQuery: Code: 253. DB::Exception: Replica r1 of shard s1 of replicated database at /test/db/test_8 already exists. Replica host ID: '146b4357c08d:9000:ee38db95-0be7-448e-98e5-40a61c7cf34b', current host ID: '146b4357c08d:9000:e0bfe6af-0459-4a94-9a00-650c70db1c2f'. (REPLICA_ALREADY_EXISTS) (version 25.3.6.10636.altinitytest (altinity build)) (from [::1]:38092) (comment: 01825_type_json_17.sql) (in query: CREATE DATABASE IF NOT EXISTS test_u4wm1fpf ENGINE=Replicated('/test/db/test_8', 's1', 'r1') ), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.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&) @ 0x0000000013db5399 4. /build/src/Databases/DatabaseReplicated.cpp:494: DB::DatabaseReplicated::tryConnectToZooKeeperAndInitDatabase(DB::LoadingStrictnessLevel) @ 0x0000000013d91155 5. /build/src/Databases/DatabaseReplicated.cpp:735: DB::DatabaseReplicated::beforeLoadingMetadata(std::shared_ptr, DB::LoadingStrictnessLevel) @ 0x0000000013d954d4 6. /build/src/Databases/TablesLoader.cpp:57: DB::TablesLoader::loadTablesAsync(std::unordered_set, std::hash>, std::equal_to>, std::allocator>>) @ 0x000000001490e734 7. /build/src/Interpreters/InterpreterCreateQuery.cpp:383: DB::InterpreterCreateQuery::createDatabase(DB::ASTCreateQuery&) @ 0x00000000148e8e14 8. /build/src/Interpreters/InterpreterCreateQuery.cpp:2351: DB::InterpreterCreateQuery::execute() @ 0x0000000014905a3a 9. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88dc9 10. /build/src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x0000000014c8ca7b 11. /build/src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000001686da12 12. /build/src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x0000000016870807 13. /build/src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x0000000016907e99 14. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 15. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 16. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 17. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 18. ? @ 0x00007fbc6213eac3 19. ? @ 0x00007fbc621d0850 2025.07.28 11:51:02.396934 [ 3285 ] {27564c41-362f-4f8a-b00b-ba369b6ad3fe} DynamicQueryHandler: Code: 253. DB::Exception: Replica r1 of shard s1 of replicated database at /test/db/test_8 already exists. Replica host ID: '146b4357c08d:9000:ee38db95-0be7-448e-98e5-40a61c7cf34b', current host ID: '146b4357c08d:9000:e0bfe6af-0459-4a94-9a00-650c70db1c2f'. (REPLICA_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.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&) @ 0x0000000013db5399 4. /build/src/Databases/DatabaseReplicated.cpp:494: DB::DatabaseReplicated::tryConnectToZooKeeperAndInitDatabase(DB::LoadingStrictnessLevel) @ 0x0000000013d91155 5. /build/src/Databases/DatabaseReplicated.cpp:735: DB::DatabaseReplicated::beforeLoadingMetadata(std::shared_ptr, DB::LoadingStrictnessLevel) @ 0x0000000013d954d4 6. /build/src/Databases/TablesLoader.cpp:57: DB::TablesLoader::loadTablesAsync(std::unordered_set, std::hash>, std::equal_to>, std::allocator>>) @ 0x000000001490e734 7. /build/src/Interpreters/InterpreterCreateQuery.cpp:383: DB::InterpreterCreateQuery::createDatabase(DB::ASTCreateQuery&) @ 0x00000000148e8e14 8. /build/src/Interpreters/InterpreterCreateQuery.cpp:2351: DB::InterpreterCreateQuery::execute() @ 0x0000000014905a3a 9. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88dc9 10. /build/src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x0000000014c8ca7b 11. /build/src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000001686da12 12. /build/src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x0000000016870807 13. /build/src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x0000000016907e99 14. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 15. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 16. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 17. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 18. ? @ 0x00007fbc6213eac3 19. ? @ 0x00007fbc621d0850 (version 25.3.6.10636.altinitytest (altinity build)) 2025.07.28 11:51:02.517574 [ 3287 ] {cddd3c84-88c9-4ebb-a532-ca88f9d8f840} executeQuery: Code: 253. DB::Exception: Replica r1 of shard s1 of replicated database at /test/db/test_8 already exists. Replica host ID: '146b4357c08d:9000:ee38db95-0be7-448e-98e5-40a61c7cf34b', current host ID: '146b4357c08d:9000:6e2b43c2-82d1-4b0e-83f5-b1a6510d82e8'. (REPLICA_ALREADY_EXISTS) (version 25.3.6.10636.altinitytest (altinity build)) (from [::1]:38102) (comment: 01079_parallel_alter_modify_zookeeper_long.sh) (in query: CREATE DATABASE IF NOT EXISTS test_j0gaendc ENGINE=Replicated('/test/db/test_8', 's1', 'r1') ), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.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&) @ 0x0000000013db5399 4. /build/src/Databases/DatabaseReplicated.cpp:494: DB::DatabaseReplicated::tryConnectToZooKeeperAndInitDatabase(DB::LoadingStrictnessLevel) @ 0x0000000013d91155 5. /build/src/Databases/DatabaseReplicated.cpp:735: DB::DatabaseReplicated::beforeLoadingMetadata(std::shared_ptr, DB::LoadingStrictnessLevel) @ 0x0000000013d954d4 6. /build/src/Databases/TablesLoader.cpp:57: DB::TablesLoader::loadTablesAsync(std::unordered_set, std::hash>, std::equal_to>, std::allocator>>) @ 0x000000001490e734 7. /build/src/Interpreters/InterpreterCreateQuery.cpp:383: DB::InterpreterCreateQuery::createDatabase(DB::ASTCreateQuery&) @ 0x00000000148e8e14 8. /build/src/Interpreters/InterpreterCreateQuery.cpp:2351: DB::InterpreterCreateQuery::execute() @ 0x0000000014905a3a 9. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88dc9 10. /build/src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x0000000014c8ca7b 11. /build/src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000001686da12 12. /build/src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x0000000016870807 13. /build/src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x0000000016907e99 14. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 15. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 16. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 17. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 18. ? @ 0x00007fbc6213eac3 19. ? @ 0x00007fbc621d0850 2025.07.28 11:51:02.559258 [ 3287 ] {cddd3c84-88c9-4ebb-a532-ca88f9d8f840} DynamicQueryHandler: Code: 253. DB::Exception: Replica r1 of shard s1 of replicated database at /test/db/test_8 already exists. Replica host ID: '146b4357c08d:9000:ee38db95-0be7-448e-98e5-40a61c7cf34b', current host ID: '146b4357c08d:9000:6e2b43c2-82d1-4b0e-83f5-b1a6510d82e8'. (REPLICA_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.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&) @ 0x0000000013db5399 4. /build/src/Databases/DatabaseReplicated.cpp:494: DB::DatabaseReplicated::tryConnectToZooKeeperAndInitDatabase(DB::LoadingStrictnessLevel) @ 0x0000000013d91155 5. /build/src/Databases/DatabaseReplicated.cpp:735: DB::DatabaseReplicated::beforeLoadingMetadata(std::shared_ptr, DB::LoadingStrictnessLevel) @ 0x0000000013d954d4 6. /build/src/Databases/TablesLoader.cpp:57: DB::TablesLoader::loadTablesAsync(std::unordered_set, std::hash>, std::equal_to>, std::allocator>>) @ 0x000000001490e734 7. /build/src/Interpreters/InterpreterCreateQuery.cpp:383: DB::InterpreterCreateQuery::createDatabase(DB::ASTCreateQuery&) @ 0x00000000148e8e14 8. /build/src/Interpreters/InterpreterCreateQuery.cpp:2351: DB::InterpreterCreateQuery::execute() @ 0x0000000014905a3a 9. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88dc9 10. /build/src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x0000000014c8ca7b 11. /build/src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000001686da12 12. /build/src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x0000000016870807 13. /build/src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x0000000016907e99 14. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 15. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 16. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 17. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 18. ? @ 0x00007fbc6213eac3 19. ? @ 0x00007fbc621d0850 (version 25.3.6.10636.altinitytest (altinity build)) 2025.07.28 11:51:02.773650 [ 7630 ] {0c51637e-6e17-452b-af80-a5cf2dc88140} executeQuery: Code: 253. DB::Exception: Replica r1 of shard s1 of replicated database at /test/db/test_8 already exists. Replica host ID: '146b4357c08d:9000:ee38db95-0be7-448e-98e5-40a61c7cf34b', current host ID: '146b4357c08d:9000:4aebc3f7-355f-41f3-a99a-31f12634a85c'. (REPLICA_ALREADY_EXISTS) (version 25.3.6.10636.altinitytest (altinity build)) (from [::1]:38104) (comment: 02943_rmt_alter_metadata_merge_checksum_mismatch.sh) (in query: CREATE DATABASE IF NOT EXISTS test_gkwifmy1 ENGINE=Replicated('/test/db/test_8', 's1', 'r1') ), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.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&) @ 0x0000000013db5399 4. /build/src/Databases/DatabaseReplicated.cpp:494: DB::DatabaseReplicated::tryConnectToZooKeeperAndInitDatabase(DB::LoadingStrictnessLevel) @ 0x0000000013d91155 5. /build/src/Databases/DatabaseReplicated.cpp:735: DB::DatabaseReplicated::beforeLoadingMetadata(std::shared_ptr, DB::LoadingStrictnessLevel) @ 0x0000000013d954d4 6. /build/src/Databases/TablesLoader.cpp:57: DB::TablesLoader::loadTablesAsync(std::unordered_set, std::hash>, std::equal_to>, std::allocator>>) @ 0x000000001490e734 7. /build/src/Interpreters/InterpreterCreateQuery.cpp:383: DB::InterpreterCreateQuery::createDatabase(DB::ASTCreateQuery&) @ 0x00000000148e8e14 8. /build/src/Interpreters/InterpreterCreateQuery.cpp:2351: DB::InterpreterCreateQuery::execute() @ 0x0000000014905a3a 9. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88dc9 10. /build/src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x0000000014c8ca7b 11. /build/src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000001686da12 12. /build/src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x0000000016870807 13. /build/src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x0000000016907e99 14. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 15. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 16. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 17. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 18. ? @ 0x00007fbc6213eac3 19. ? @ 0x00007fbc621d0850 2025.07.28 11:51:02.782806 [ 7630 ] {0c51637e-6e17-452b-af80-a5cf2dc88140} DynamicQueryHandler: Code: 253. DB::Exception: Replica r1 of shard s1 of replicated database at /test/db/test_8 already exists. Replica host ID: '146b4357c08d:9000:ee38db95-0be7-448e-98e5-40a61c7cf34b', current host ID: '146b4357c08d:9000:4aebc3f7-355f-41f3-a99a-31f12634a85c'. (REPLICA_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.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&) @ 0x0000000013db5399 4. /build/src/Databases/DatabaseReplicated.cpp:494: DB::DatabaseReplicated::tryConnectToZooKeeperAndInitDatabase(DB::LoadingStrictnessLevel) @ 0x0000000013d91155 5. /build/src/Databases/DatabaseReplicated.cpp:735: DB::DatabaseReplicated::beforeLoadingMetadata(std::shared_ptr, DB::LoadingStrictnessLevel) @ 0x0000000013d954d4 6. /build/src/Databases/TablesLoader.cpp:57: DB::TablesLoader::loadTablesAsync(std::unordered_set, std::hash>, std::equal_to>, std::allocator>>) @ 0x000000001490e734 7. /build/src/Interpreters/InterpreterCreateQuery.cpp:383: DB::InterpreterCreateQuery::createDatabase(DB::ASTCreateQuery&) @ 0x00000000148e8e14 8. /build/src/Interpreters/InterpreterCreateQuery.cpp:2351: DB::InterpreterCreateQuery::execute() @ 0x0000000014905a3a 9. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88dc9 10. /build/src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x0000000014c8ca7b 11. /build/src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000001686da12 12. /build/src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x0000000016870807 13. /build/src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x0000000016907e99 14. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 15. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 16. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 17. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 18. ? @ 0x00007fbc6213eac3 19. ? @ 0x00007fbc621d0850 (version 25.3.6.10636.altinitytest (altinity build)) 2025.07.28 11:51:02.890056 [ 5327 ] {70cad953-80d1-48b9-b75d-269d84a9b26c} executeQuery: Code: 253. DB::Exception: Replica r1 of shard s1 of replicated database at /test/db/test_8 already exists. Replica host ID: '146b4357c08d:9000:ee38db95-0be7-448e-98e5-40a61c7cf34b', current host ID: '146b4357c08d:9000:9a2f7d38-ed81-4537-8a1b-bd9611e49d4f'. (REPLICA_ALREADY_EXISTS) (version 25.3.6.10636.altinitytest (altinity build)) (from [::1]:38128) (comment: 02294_fp_seconds_profile.sql) (in query: CREATE DATABASE IF NOT EXISTS test_k2miagvk ENGINE=Replicated('/test/db/test_8', 's1', 'r1') ), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.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&) @ 0x0000000013db5399 4. /build/src/Databases/DatabaseReplicated.cpp:494: DB::DatabaseReplicated::tryConnectToZooKeeperAndInitDatabase(DB::LoadingStrictnessLevel) @ 0x0000000013d91155 5. /build/src/Databases/DatabaseReplicated.cpp:735: DB::DatabaseReplicated::beforeLoadingMetadata(std::shared_ptr, DB::LoadingStrictnessLevel) @ 0x0000000013d954d4 6. /build/src/Databases/TablesLoader.cpp:57: DB::TablesLoader::loadTablesAsync(std::unordered_set, std::hash>, std::equal_to>, std::allocator>>) @ 0x000000001490e734 7. /build/src/Interpreters/InterpreterCreateQuery.cpp:383: DB::InterpreterCreateQuery::createDatabase(DB::ASTCreateQuery&) @ 0x00000000148e8e14 8. /build/src/Interpreters/InterpreterCreateQuery.cpp:2351: DB::InterpreterCreateQuery::execute() @ 0x0000000014905a3a 9. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88dc9 10. /build/src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x0000000014c8ca7b 11. /build/src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000001686da12 12. /build/src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x0000000016870807 13. /build/src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x0000000016907e99 14. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 15. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 16. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 17. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 18. ? @ 0x00007fbc6213eac3 19. ? @ 0x00007fbc621d0850 2025.07.28 11:51:02.903406 [ 5327 ] {70cad953-80d1-48b9-b75d-269d84a9b26c} DynamicQueryHandler: Code: 253. DB::Exception: Replica r1 of shard s1 of replicated database at /test/db/test_8 already exists. Replica host ID: '146b4357c08d:9000:ee38db95-0be7-448e-98e5-40a61c7cf34b', current host ID: '146b4357c08d:9000:9a2f7d38-ed81-4537-8a1b-bd9611e49d4f'. (REPLICA_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.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&) @ 0x0000000013db5399 4. /build/src/Databases/DatabaseReplicated.cpp:494: DB::DatabaseReplicated::tryConnectToZooKeeperAndInitDatabase(DB::LoadingStrictnessLevel) @ 0x0000000013d91155 5. /build/src/Databases/DatabaseReplicated.cpp:735: DB::DatabaseReplicated::beforeLoadingMetadata(std::shared_ptr, DB::LoadingStrictnessLevel) @ 0x0000000013d954d4 6. /build/src/Databases/TablesLoader.cpp:57: DB::TablesLoader::loadTablesAsync(std::unordered_set, std::hash>, std::equal_to>, std::allocator>>) @ 0x000000001490e734 7. /build/src/Interpreters/InterpreterCreateQuery.cpp:383: DB::InterpreterCreateQuery::createDatabase(DB::ASTCreateQuery&) @ 0x00000000148e8e14 8. /build/src/Interpreters/InterpreterCreateQuery.cpp:2351: DB::InterpreterCreateQuery::execute() @ 0x0000000014905a3a 9. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88dc9 10. /build/src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x0000000014c8ca7b 11. /build/src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000001686da12 12. /build/src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x0000000016870807 13. /build/src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x0000000016907e99 14. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 15. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 16. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 17. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 18. ? @ 0x00007fbc6213eac3 19. ? @ 0x00007fbc621d0850 (version 25.3.6.10636.altinitytest (altinity build)) 2025.07.28 11:51:03.061894 [ 3287 ] {b9d3fc3f-21eb-4beb-b1de-6c1c3a51602f} executeQuery: Code: 253. DB::Exception: Replica r1 of shard s1 of replicated database at /test/db/test_8 already exists. Replica host ID: '146b4357c08d:9000:ee38db95-0be7-448e-98e5-40a61c7cf34b', current host ID: '146b4357c08d:9000:84e356b8-b4c6-4f54-9542-6a3beab159fb'. (REPLICA_ALREADY_EXISTS) (version 25.3.6.10636.altinitytest (altinity build)) (from [::1]:38134) (comment: 02015_global_in_threads.sh) (in query: CREATE DATABASE IF NOT EXISTS test_jqa1cpov ENGINE=Replicated('/test/db/test_8', 's1', 'r1') ), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.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&) @ 0x0000000013db5399 4. /build/src/Databases/DatabaseReplicated.cpp:494: DB::DatabaseReplicated::tryConnectToZooKeeperAndInitDatabase(DB::LoadingStrictnessLevel) @ 0x0000000013d91155 5. /build/src/Databases/DatabaseReplicated.cpp:735: DB::DatabaseReplicated::beforeLoadingMetadata(std::shared_ptr, DB::LoadingStrictnessLevel) @ 0x0000000013d954d4 6. /build/src/Databases/TablesLoader.cpp:57: DB::TablesLoader::loadTablesAsync(std::unordered_set, std::hash>, std::equal_to>, std::allocator>>) @ 0x000000001490e734 7. /build/src/Interpreters/InterpreterCreateQuery.cpp:383: DB::InterpreterCreateQuery::createDatabase(DB::ASTCreateQuery&) @ 0x00000000148e8e14 8. /build/src/Interpreters/InterpreterCreateQuery.cpp:2351: DB::InterpreterCreateQuery::execute() @ 0x0000000014905a3a 9. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88dc9 10. /build/src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x0000000014c8ca7b 11. /build/src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000001686da12 12. /build/src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x0000000016870807 13. /build/src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x0000000016907e99 14. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 15. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 16. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 17. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 18. ? @ 0x00007fbc6213eac3 19. ? @ 0x00007fbc621d0850 2025.07.28 11:51:03.065553 [ 3287 ] {b9d3fc3f-21eb-4beb-b1de-6c1c3a51602f} DynamicQueryHandler: Code: 253. DB::Exception: Replica r1 of shard s1 of replicated database at /test/db/test_8 already exists. Replica host ID: '146b4357c08d:9000:ee38db95-0be7-448e-98e5-40a61c7cf34b', current host ID: '146b4357c08d:9000:84e356b8-b4c6-4f54-9542-6a3beab159fb'. (REPLICA_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.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&) @ 0x0000000013db5399 4. /build/src/Databases/DatabaseReplicated.cpp:494: DB::DatabaseReplicated::tryConnectToZooKeeperAndInitDatabase(DB::LoadingStrictnessLevel) @ 0x0000000013d91155 5. /build/src/Databases/DatabaseReplicated.cpp:735: DB::DatabaseReplicated::beforeLoadingMetadata(std::shared_ptr, DB::LoadingStrictnessLevel) @ 0x0000000013d954d4 6. /build/src/Databases/TablesLoader.cpp:57: DB::TablesLoader::loadTablesAsync(std::unordered_set, std::hash>, std::equal_to>, std::allocator>>) @ 0x000000001490e734 7. /build/src/Interpreters/InterpreterCreateQuery.cpp:383: DB::InterpreterCreateQuery::createDatabase(DB::ASTCreateQuery&) @ 0x00000000148e8e14 8. /build/src/Interpreters/InterpreterCreateQuery.cpp:2351: DB::InterpreterCreateQuery::execute() @ 0x0000000014905a3a 9. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88dc9 10. /build/src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x0000000014c8ca7b 11. /build/src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000001686da12 12. /build/src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x0000000016870807 13. /build/src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x0000000016907e99 14. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 15. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 16. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 17. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 18. ? @ 0x00007fbc6213eac3 19. ? @ 0x00007fbc621d0850 (version 25.3.6.10636.altinitytest (altinity build)) 2025.07.28 11:51:03.168221 [ 4900 ] {8f3b54bb-1c59-486c-8a32-e31f44b7d216} executeQuery: Code: 253. DB::Exception: Replica r1 of shard s1 of replicated database at /test/db/test_8 already exists. Replica host ID: '146b4357c08d:9000:ee38db95-0be7-448e-98e5-40a61c7cf34b', current host ID: '146b4357c08d:9000:d18a08f7-1fb1-4a0b-907b-411db49970a7'. (REPLICA_ALREADY_EXISTS) (version 25.3.6.10636.altinitytest (altinity build)) (from [::1]:38158) (comment: 02187_msg_pack_uuid.sh) (in query: CREATE DATABASE IF NOT EXISTS test_6s8gz03u ENGINE=Replicated('/test/db/test_8', 's1', 'r1') ), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.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&) @ 0x0000000013db5399 4. /build/src/Databases/DatabaseReplicated.cpp:494: DB::DatabaseReplicated::tryConnectToZooKeeperAndInitDatabase(DB::LoadingStrictnessLevel) @ 0x0000000013d91155 5. /build/src/Databases/DatabaseReplicated.cpp:735: DB::DatabaseReplicated::beforeLoadingMetadata(std::shared_ptr, DB::LoadingStrictnessLevel) @ 0x0000000013d954d4 6. /build/src/Databases/TablesLoader.cpp:57: DB::TablesLoader::loadTablesAsync(std::unordered_set, std::hash>, std::equal_to>, std::allocator>>) @ 0x000000001490e734 7. /build/src/Interpreters/InterpreterCreateQuery.cpp:383: DB::InterpreterCreateQuery::createDatabase(DB::ASTCreateQuery&) @ 0x00000000148e8e14 8. /build/src/Interpreters/InterpreterCreateQuery.cpp:2351: DB::InterpreterCreateQuery::execute() @ 0x0000000014905a3a 9. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88dc9 10. /build/src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x0000000014c8ca7b 11. /build/src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000001686da12 12. /build/src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x0000000016870807 13. /build/src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x0000000016907e99 14. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 15. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 16. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 17. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 18. ? @ 0x00007fbc6213eac3 19. ? @ 0x00007fbc621d0850 2025.07.28 11:51:03.253151 [ 4900 ] {8f3b54bb-1c59-486c-8a32-e31f44b7d216} DynamicQueryHandler: Code: 253. DB::Exception: Replica r1 of shard s1 of replicated database at /test/db/test_8 already exists. Replica host ID: '146b4357c08d:9000:ee38db95-0be7-448e-98e5-40a61c7cf34b', current host ID: '146b4357c08d:9000:d18a08f7-1fb1-4a0b-907b-411db49970a7'. (REPLICA_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.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&) @ 0x0000000013db5399 4. /build/src/Databases/DatabaseReplicated.cpp:494: DB::DatabaseReplicated::tryConnectToZooKeeperAndInitDatabase(DB::LoadingStrictnessLevel) @ 0x0000000013d91155 5. /build/src/Databases/DatabaseReplicated.cpp:735: DB::DatabaseReplicated::beforeLoadingMetadata(std::shared_ptr, DB::LoadingStrictnessLevel) @ 0x0000000013d954d4 6. /build/src/Databases/TablesLoader.cpp:57: DB::TablesLoader::loadTablesAsync(std::unordered_set, std::hash>, std::equal_to>, std::allocator>>) @ 0x000000001490e734 7. /build/src/Interpreters/InterpreterCreateQuery.cpp:383: DB::InterpreterCreateQuery::createDatabase(DB::ASTCreateQuery&) @ 0x00000000148e8e14 8. /build/src/Interpreters/InterpreterCreateQuery.cpp:2351: DB::InterpreterCreateQuery::execute() @ 0x0000000014905a3a 9. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88dc9 10. /build/src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x0000000014c8ca7b 11. /build/src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000001686da12 12. /build/src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x0000000016870807 13. /build/src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x0000000016907e99 14. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 15. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 16. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 17. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 18. ? @ 0x00007fbc6213eac3 19. ? @ 0x00007fbc621d0850 (version 25.3.6.10636.altinitytest (altinity build)) 2025.07.28 11:51:03.375556 [ 5320 ] {e63d40df-aa71-4ba0-aa68-a63f10322495} executeQuery: Code: 253. DB::Exception: Replica r1 of shard s1 of replicated database at /test/db/test_8 already exists. Replica host ID: '146b4357c08d:9000:ee38db95-0be7-448e-98e5-40a61c7cf34b', current host ID: '146b4357c08d:9000:3522fd83-435b-44bb-8093-893992cdb879'. (REPLICA_ALREADY_EXISTS) (version 25.3.6.10636.altinitytest (altinity build)) (from [::1]:38174) (comment: 00059_merge_sorting_empty_array_joined.sql) (in query: CREATE DATABASE IF NOT EXISTS test_eh07v9c0 ENGINE=Replicated('/test/db/test_8', 's1', 'r1') ), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.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&) @ 0x0000000013db5399 4. /build/src/Databases/DatabaseReplicated.cpp:494: DB::DatabaseReplicated::tryConnectToZooKeeperAndInitDatabase(DB::LoadingStrictnessLevel) @ 0x0000000013d91155 5. /build/src/Databases/DatabaseReplicated.cpp:735: DB::DatabaseReplicated::beforeLoadingMetadata(std::shared_ptr, DB::LoadingStrictnessLevel) @ 0x0000000013d954d4 6. /build/src/Databases/TablesLoader.cpp:57: DB::TablesLoader::loadTablesAsync(std::unordered_set, std::hash>, std::equal_to>, std::allocator>>) @ 0x000000001490e734 7. /build/src/Interpreters/InterpreterCreateQuery.cpp:383: DB::InterpreterCreateQuery::createDatabase(DB::ASTCreateQuery&) @ 0x00000000148e8e14 8. /build/src/Interpreters/InterpreterCreateQuery.cpp:2351: DB::InterpreterCreateQuery::execute() @ 0x0000000014905a3a 9. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88dc9 10. /build/src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x0000000014c8ca7b 11. /build/src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000001686da12 12. /build/src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x0000000016870807 13. /build/src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x0000000016907e99 14. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 15. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 16. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 17. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 18. ? @ 0x00007fbc6213eac3 19. ? @ 0x00007fbc621d0850 2025.07.28 11:51:03.407657 [ 5320 ] {e63d40df-aa71-4ba0-aa68-a63f10322495} DynamicQueryHandler: Code: 253. DB::Exception: Replica r1 of shard s1 of replicated database at /test/db/test_8 already exists. Replica host ID: '146b4357c08d:9000:ee38db95-0be7-448e-98e5-40a61c7cf34b', current host ID: '146b4357c08d:9000:3522fd83-435b-44bb-8093-893992cdb879'. (REPLICA_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.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&) @ 0x0000000013db5399 4. /build/src/Databases/DatabaseReplicated.cpp:494: DB::DatabaseReplicated::tryConnectToZooKeeperAndInitDatabase(DB::LoadingStrictnessLevel) @ 0x0000000013d91155 5. /build/src/Databases/DatabaseReplicated.cpp:735: DB::DatabaseReplicated::beforeLoadingMetadata(std::shared_ptr, DB::LoadingStrictnessLevel) @ 0x0000000013d954d4 6. /build/src/Databases/TablesLoader.cpp:57: DB::TablesLoader::loadTablesAsync(std::unordered_set, std::hash>, std::equal_to>, std::allocator>>) @ 0x000000001490e734 7. /build/src/Interpreters/InterpreterCreateQuery.cpp:383: DB::InterpreterCreateQuery::createDatabase(DB::ASTCreateQuery&) @ 0x00000000148e8e14 8. /build/src/Interpreters/InterpreterCreateQuery.cpp:2351: DB::InterpreterCreateQuery::execute() @ 0x0000000014905a3a 9. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88dc9 10. /build/src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x0000000014c8ca7b 11. /build/src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000001686da12 12. /build/src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x0000000016870807 13. /build/src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x0000000016907e99 14. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 15. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 16. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 17. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 18. ? @ 0x00007fbc6213eac3 19. ? @ 0x00007fbc621d0850 (version 25.3.6.10636.altinitytest (altinity build)) 2025.07.28 11:51:04.405593 [ 5320 ] {6782eded-5d6e-4cff-8067-3e6c11b5b89e} executeQuery: Code: 36. DB::Exception: Only `Float64` data type is allowed for the value column of GraphiteMergeTree. (BAD_ARGUMENTS) (version 25.3.6.10636.altinitytest (altinity build)) (from [::1]:50680) (comment: 02508_bad_graphite.sql) (query 3, line 5) (in query: INSERT INTO test_graphite (key) VALUES ), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000000a074fcb 4. /build/src/Processors/Merges/Algorithms/GraphiteRollupSortedAlgorithm.cpp:36: DB::GraphiteRollupSortedAlgorithm::GraphiteRollupSortedAlgorithm(DB::Block const&, unsigned long, DB::SortDescription, unsigned long, unsigned long, DB::Graphite::Params, long) @ 0x0000000016d06879 5. /build/contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: DB::GraphiteRollupSortedAlgorithm* std::construct_at[abi:se190107](DB::GraphiteRollupSortedAlgorithm*, DB::Block&, int&&, DB::SortDescription&, unsigned long&&, int&&, DB::Graphite::Params const&, long&&) @ 0x00000000164144a1 6. /build/contrib/llvm-project/libcxx/include/__memory/construct_at.h:49: DB::MergeTreeDataWriter::mergeBlock(DB::Block&&, DB::SortDescription, std::vector> const&, DB::PODArray, 63ul, 64ul>*&, DB::MergeTreeData::MergingParams const&) @ 0x0000000016409a82 7. /build/src/Storages/MergeTree/MergeTreeDataWriter.cpp:613: DB::MergeTreeDataWriter::writeTempPartImpl(DB::BlockWithPartition&, std::shared_ptr const&, std::shared_ptr, long, bool) @ 0x000000001640bce1 8. /build/src/Storages/MergeTree/MergeTreeDataWriter.cpp:485: DB::MergeTreeDataWriter::writeTempPart(DB::BlockWithPartition&, std::shared_ptr const&, std::shared_ptr) @ 0x000000001640a7df 9. /build/src/Storages/MergeTree/MergeTreeSink.cpp:127: DB::MergeTreeSink::consume(DB::Chunk&) @ 0x000000001666cf54 10. /build/src/Processors/Sinks/SinkToStorage.cpp:10: DB::SinkToStorage::onConsume(DB::Chunk) @ 0x0000000016cee093 11. /build/src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: void std::__function::__policy_invoker::__call_impl[abi:se190107]>(std::__function::__policy_storage const*) @ 0x0000000016c0ad89 12. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000016c0abf5 13. /build/src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: DB::ExceptionKeepingTransform::work() @ 0x0000000016c0a6fe 14. /build/src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x00000000169bd00f 15. /build/src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x00000000169b2105 16. /build/src/Processors/Executors/PipelineExecutor.cpp:170: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x00000000169b16a7 17. /build/src/Processors/Executors/PushingPipelineExecutor.cpp:131: DB::PushingPipelineExecutor::finish() @ 0x00000000169c359f 18. /build/src/Server/TCPHandler.cpp:1128: DB::TCPHandler::processInsertQuery(DB::QueryState&) @ 0x00000000168f0d2c 19. /build/src/Server/TCPHandler.cpp:673: DB::TCPHandler::runImpl() @ 0x00000000168e68bc 20. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 21. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 22. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 23. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 24. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 25. ? @ 0x00007fbc6213eac3 26. ? @ 0x00007fbc621d0850 2025.07.28 11:51:04.410560 [ 5320 ] {} TCPHandler: Code: 36. DB::Exception: Only `Float64` data type is allowed for the value column of GraphiteMergeTree. (BAD_ARGUMENTS), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000000a074fcb 4. /build/src/Processors/Merges/Algorithms/GraphiteRollupSortedAlgorithm.cpp:36: DB::GraphiteRollupSortedAlgorithm::GraphiteRollupSortedAlgorithm(DB::Block const&, unsigned long, DB::SortDescription, unsigned long, unsigned long, DB::Graphite::Params, long) @ 0x0000000016d06879 5. /build/contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: DB::GraphiteRollupSortedAlgorithm* std::construct_at[abi:se190107](DB::GraphiteRollupSortedAlgorithm*, DB::Block&, int&&, DB::SortDescription&, unsigned long&&, int&&, DB::Graphite::Params const&, long&&) @ 0x00000000164144a1 6. /build/contrib/llvm-project/libcxx/include/__memory/construct_at.h:49: DB::MergeTreeDataWriter::mergeBlock(DB::Block&&, DB::SortDescription, std::vector> const&, DB::PODArray, 63ul, 64ul>*&, DB::MergeTreeData::MergingParams const&) @ 0x0000000016409a82 7. /build/src/Storages/MergeTree/MergeTreeDataWriter.cpp:613: DB::MergeTreeDataWriter::writeTempPartImpl(DB::BlockWithPartition&, std::shared_ptr const&, std::shared_ptr, long, bool) @ 0x000000001640bce1 8. /build/src/Storages/MergeTree/MergeTreeDataWriter.cpp:485: DB::MergeTreeDataWriter::writeTempPart(DB::BlockWithPartition&, std::shared_ptr const&, std::shared_ptr) @ 0x000000001640a7df 9. /build/src/Storages/MergeTree/MergeTreeSink.cpp:127: DB::MergeTreeSink::consume(DB::Chunk&) @ 0x000000001666cf54 10. /build/src/Processors/Sinks/SinkToStorage.cpp:10: DB::SinkToStorage::onConsume(DB::Chunk) @ 0x0000000016cee093 11. /build/src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: void std::__function::__policy_invoker::__call_impl[abi:se190107]>(std::__function::__policy_storage const*) @ 0x0000000016c0ad89 12. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000016c0abf5 13. /build/src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: DB::ExceptionKeepingTransform::work() @ 0x0000000016c0a6fe 14. /build/src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x00000000169bd00f 15. /build/src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x00000000169b2105 16. /build/src/Processors/Executors/PipelineExecutor.cpp:170: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x00000000169b16a7 17. /build/src/Processors/Executors/PushingPipelineExecutor.cpp:131: DB::PushingPipelineExecutor::finish() @ 0x00000000169c359f 18. /build/src/Server/TCPHandler.cpp:1128: DB::TCPHandler::processInsertQuery(DB::QueryState&) @ 0x00000000168f0d2c 19. /build/src/Server/TCPHandler.cpp:673: DB::TCPHandler::runImpl() @ 0x00000000168e68bc 20. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 21. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 22. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 23. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 24. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 25. ? @ 0x00007fbc6213eac3 26. ? @ 0x00007fbc621d0850 2025.07.28 11:51:05.141557 [ 3285 ] {e89daf2d-59a2-4897-970e-175d64ab456c} executeQuery: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=11, jobs=0): While executing MergeTreeSelect(pool: ReadPoolInOrder, algorithm: InOrder). (CANNOT_SCHEDULE_TASK) (version 25.3.6.10636.altinitytest (altinity build)) (from [::ffff:127.0.0.1]:47378) (comment: 01882_total_rows_approx.sh) (in query: select * from data_01882 ), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000fccaeeb 4. /build/src/Common/ThreadPool.cpp:275: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000fccc813 5. /build/src/Common/ThreadPool.cpp:323: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fcc7bbc 6. /build/src/Common/ThreadPool.cpp:494: ThreadPoolImpl>::scheduleOrThrowOnError(std::function, Priority) @ 0x000000000fcc7a0e 7. /build/src/Common/threadPoolCallbackRunner.h:52: std::future> std::__function::__policy_invoker> (DB::MergeTreeMarksLoader::loadMarksAsync()::$_0&&, Priority)>::__call_impl[abi:se190107]> (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&&) @ 0x0000000016474731 8. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000016471940 9. /build/src/Storages/MergeTree/MergeTreeMarksLoader.cpp:83: DB::MergeTreeMarksLoader::startAsyncLoad() @ 0x000000001647173f 10. /build/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) @ 0x000000001648df37 11. /build/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&&) @ 0x00000000163c608d 12. /build/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 @ 0x00000000163c27d4 13. /build/src/Storages/MergeTree/MergeTreeReadTask.cpp:60: DB::MergeTreeReadTask::createReaders(std::shared_ptr const&, DB::MergeTreeReadTask::Extras const&, DB::MarkRanges const&) @ 0x00000000164b5386 14. /build/src/Storages/MergeTree/MergeTreeReadPoolBase.cpp:274: DB::MergeTreeReadPoolBase::createTask(std::shared_ptr, DB::MarkRanges, DB::MergeTreeReadTask*) const @ 0x0000000016e53b1f 15. /build/src/Storages/MergeTree/MergeTreeReadPoolInOrder.cpp:74: DB::MergeTreeReadPoolInOrder::getTask(unsigned long, DB::MergeTreeReadTask*) @ 0x0000000016e7808a 16. /build/src/Storages/MergeTree/MergeTreeSelectProcessor.cpp:191: DB::MergeTreeSelectProcessor::read() @ 0x00000000164c0b40 17. /build/src/Storages/MergeTree/MergeTreeSource.cpp:229: DB::MergeTreeSource::tryGenerate() @ 0x0000000016e43d69 18. /build/src/Processors/ISource.cpp:108: DB::ISource::work() @ 0x00000000169a21e7 19. /build/src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x00000000169bd00f 20. /build/src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x00000000169b2105 21. /build/src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeSingleThread(unsigned long) @ 0x00000000169b23be 22. /build/src/Processors/Executors/PipelineExecutor.cpp:454: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x00000000169b0be7 23. /build/src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x00000000169b03f4 24. /build/src/Processors/Executors/CompletedPipelineExecutor.cpp:105: DB::CompletedPipelineExecutor::execute() @ 0x00000000169af3c4 25. /build/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&)>) @ 0x0000000014c8d123 26. /build/src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000001686da12 27. /build/src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x0000000016870807 28. /build/src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x0000000016907e99 29. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 30. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 31. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 2025.07.28 11:51:05.152341 [ 3285 ] {e89daf2d-59a2-4897-970e-175d64ab456c} DynamicQueryHandler: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=11, jobs=0): While executing MergeTreeSelect(pool: ReadPoolInOrder, algorithm: InOrder). (CANNOT_SCHEDULE_TASK), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000fccaeeb 4. /build/src/Common/ThreadPool.cpp:275: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000fccc813 5. /build/src/Common/ThreadPool.cpp:323: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fcc7bbc 6. /build/src/Common/ThreadPool.cpp:494: ThreadPoolImpl>::scheduleOrThrowOnError(std::function, Priority) @ 0x000000000fcc7a0e 7. /build/src/Common/threadPoolCallbackRunner.h:52: std::future> std::__function::__policy_invoker> (DB::MergeTreeMarksLoader::loadMarksAsync()::$_0&&, Priority)>::__call_impl[abi:se190107]> (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&&) @ 0x0000000016474731 8. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000016471940 9. /build/src/Storages/MergeTree/MergeTreeMarksLoader.cpp:83: DB::MergeTreeMarksLoader::startAsyncLoad() @ 0x000000001647173f 10. /build/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) @ 0x000000001648df37 11. /build/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&&) @ 0x00000000163c608d 12. /build/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 @ 0x00000000163c27d4 13. /build/src/Storages/MergeTree/MergeTreeReadTask.cpp:60: DB::MergeTreeReadTask::createReaders(std::shared_ptr const&, DB::MergeTreeReadTask::Extras const&, DB::MarkRanges const&) @ 0x00000000164b5386 14. /build/src/Storages/MergeTree/MergeTreeReadPoolBase.cpp:274: DB::MergeTreeReadPoolBase::createTask(std::shared_ptr, DB::MarkRanges, DB::MergeTreeReadTask*) const @ 0x0000000016e53b1f 15. /build/src/Storages/MergeTree/MergeTreeReadPoolInOrder.cpp:74: DB::MergeTreeReadPoolInOrder::getTask(unsigned long, DB::MergeTreeReadTask*) @ 0x0000000016e7808a 16. /build/src/Storages/MergeTree/MergeTreeSelectProcessor.cpp:191: DB::MergeTreeSelectProcessor::read() @ 0x00000000164c0b40 17. /build/src/Storages/MergeTree/MergeTreeSource.cpp:229: DB::MergeTreeSource::tryGenerate() @ 0x0000000016e43d69 18. /build/src/Processors/ISource.cpp:108: DB::ISource::work() @ 0x00000000169a21e7 19. /build/src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x00000000169bd00f 20. /build/src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x00000000169b2105 21. /build/src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeSingleThread(unsigned long) @ 0x00000000169b23be 22. /build/src/Processors/Executors/PipelineExecutor.cpp:454: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x00000000169b0be7 23. /build/src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x00000000169b03f4 24. /build/src/Processors/Executors/CompletedPipelineExecutor.cpp:105: DB::CompletedPipelineExecutor::execute() @ 0x00000000169af3c4 25. /build/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&)>) @ 0x0000000014c8d123 26. /build/src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000001686da12 27. /build/src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x0000000016870807 28. /build/src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x0000000016907e99 29. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 30. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 31. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 (version 25.3.6.10636.altinitytest (altinity build)) 2025.07.28 11:51:05.727267 [ 5327 ] {8d5f6694-e7b1-40f8-845a-430d0a1064d8} executeQuery: Code: 999. DB::Exception: Fault injection before operation. (KEEPER_EXCEPTION) (version 25.3.6.10636.altinitytest (altinity build)) (from [::1]:50632) (comment: 02456_keeper_retries_during_insert.sql) (query 6, line 10) (in query: INSERT INTO keeper_retries_r1 SETTINGS insert_keeper_fault_injection_probability=1, insert_keeper_max_retries=0 VALUES ), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: Coordination::Exception::Exception(T&&, Coordination::Error) @ 0x000000001719535e 3. /build/src/Common/ZooKeeper/KeeperException.h:58: Coordination::Exception Coordination::Exception::fromMessage(Coordination::Error, T&&) @ 0x0000000017193090 4. /build/src/Common/ZooKeeper/ZooKeeperWithFaultInjection.cpp:107: DB::ZooKeeperWithFaultInjection::injectFailureBeforeOperationThrow(char const*, String const&) @ 0x000000001718d587 5. /build/src/Common/ZooKeeper/ZooKeeperWithFaultInjection.cpp:134: DB::ZooKeeperWithFaultInjection::exists(String const&, Coordination::Stat*, std::shared_ptr const&) @ 0x000000001718ece7 6. /build/src/Storages/StorageReplicatedMergeTree.cpp:7078: DB::StorageReplicatedMergeTree::existsNodeCached(std::shared_ptr const&, String const&) const @ 0x0000000015e85d42 7. /build/src/Storages/StorageReplicatedMergeTree.cpp:7115: std::optional DB::StorageReplicatedMergeTree::allocateBlockNumber(String const&, std::shared_ptr const&, String const&, String const&) const @ 0x0000000015f9da3c 8. /build/src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:898: DB::ReplicatedMergeTreeSinkImpl::commitPart(std::shared_ptr const&, std::shared_ptr&, String const&, unsigned long)::'lambda1'()::operator()() const @ 0x000000001660d433 9. /build/src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:1124: DB::ReplicatedMergeTreeSinkImpl::commitPart(std::shared_ptr const&, std::shared_ptr&, String const&, unsigned long)::'lambda2'()::operator()() const @ 0x000000001660d1f2 10. /build/src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:1157: void DB::ZooKeeperRetriesControl::retryLoop::commitPart(std::shared_ptr const&, std::shared_ptr&, String const&, unsigned long)::'lambda3'()&, void DB::ZooKeeperRetriesControl::retryLoop::commitPart(std::shared_ptr const&, std::shared_ptr&, String const&, unsigned long)::'lambda3'()>(DB::ReplicatedMergeTreeSinkImpl::commitPart(std::shared_ptr const&, std::shared_ptr&, String const&, unsigned long)::'lambda3'()&&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::commitPart(std::shared_ptr const&, std::shared_ptr&, String const&, unsigned long)::'lambda3'()&&, void DB::ZooKeeperRetriesControl::retryLoop::commitPart(std::shared_ptr const&, std::shared_ptr&, String const&, unsigned long)::'lambda3'()>(DB::ReplicatedMergeTreeSinkImpl::commitPart(std::shared_ptr const&, std::shared_ptr&, String const&, unsigned long)::'lambda3'()&&)::'lambda'()&&) @ 0x000000001660d07f 11. /build/src/Common/ZooKeeper/ZooKeeperRetries.h:52: DB::ReplicatedMergeTreeSinkImpl::commitPart(std::shared_ptr const&, std::shared_ptr&, String const&, unsigned long) @ 0x00000000165fd951 12. /build/src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:492: DB::ReplicatedMergeTreeSinkImpl::finishDelayedChunk(std::shared_ptr const&) @ 0x00000000165f277d 13. /build/src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:1235: DB::ReplicatedMergeTreeSinkImpl::onFinish() @ 0x00000000165fd175 14. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000016c0abf5 15. /build/src/Processors/Transforms/ExceptionKeepingTransform.cpp:187: DB::ExceptionKeepingTransform::work() @ 0x0000000016c0a7bc 16. /build/src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x00000000169bd00f 17. /build/src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x00000000169b2105 18. /build/src/Processors/Executors/PipelineExecutor.cpp:170: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x00000000169b16a7 19. /build/src/Processors/Executors/PushingPipelineExecutor.cpp:131: DB::PushingPipelineExecutor::finish() @ 0x00000000169c359f 20. /build/src/Server/TCPHandler.cpp:1128: DB::TCPHandler::processInsertQuery(DB::QueryState&) @ 0x00000000168f0d2c 21. /build/src/Server/TCPHandler.cpp:673: DB::TCPHandler::runImpl() @ 0x00000000168e68bc 22. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 23. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 24. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 25. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 26. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 27. ? @ 0x00007fbc6213eac3 28. ? @ 0x00007fbc621d0850 2025.07.28 11:51:05.744644 [ 5327 ] {} TCPHandler: Code: 999. Coordination::Exception: Fault injection before operation. (KEEPER_EXCEPTION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: Coordination::Exception::Exception(T&&, Coordination::Error) @ 0x000000001719535e 3. /build/src/Common/ZooKeeper/KeeperException.h:58: Coordination::Exception Coordination::Exception::fromMessage(Coordination::Error, T&&) @ 0x0000000017193090 4. /build/src/Common/ZooKeeper/ZooKeeperWithFaultInjection.cpp:107: DB::ZooKeeperWithFaultInjection::injectFailureBeforeOperationThrow(char const*, String const&) @ 0x000000001718d587 5. /build/src/Common/ZooKeeper/ZooKeeperWithFaultInjection.cpp:134: DB::ZooKeeperWithFaultInjection::exists(String const&, Coordination::Stat*, std::shared_ptr const&) @ 0x000000001718ece7 6. /build/src/Storages/StorageReplicatedMergeTree.cpp:7078: DB::StorageReplicatedMergeTree::existsNodeCached(std::shared_ptr const&, String const&) const @ 0x0000000015e85d42 7. /build/src/Storages/StorageReplicatedMergeTree.cpp:7115: std::optional DB::StorageReplicatedMergeTree::allocateBlockNumber(String const&, std::shared_ptr const&, String const&, String const&) const @ 0x0000000015f9da3c 8. /build/src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:898: DB::ReplicatedMergeTreeSinkImpl::commitPart(std::shared_ptr const&, std::shared_ptr&, String const&, unsigned long)::'lambda1'()::operator()() const @ 0x000000001660d433 9. /build/src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:1124: DB::ReplicatedMergeTreeSinkImpl::commitPart(std::shared_ptr const&, std::shared_ptr&, String const&, unsigned long)::'lambda2'()::operator()() const @ 0x000000001660d1f2 10. /build/src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:1157: void DB::ZooKeeperRetriesControl::retryLoop::commitPart(std::shared_ptr const&, std::shared_ptr&, String const&, unsigned long)::'lambda3'()&, void DB::ZooKeeperRetriesControl::retryLoop::commitPart(std::shared_ptr const&, std::shared_ptr&, String const&, unsigned long)::'lambda3'()>(DB::ReplicatedMergeTreeSinkImpl::commitPart(std::shared_ptr const&, std::shared_ptr&, String const&, unsigned long)::'lambda3'()&&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::commitPart(std::shared_ptr const&, std::shared_ptr&, String const&, unsigned long)::'lambda3'()&&, void DB::ZooKeeperRetriesControl::retryLoop::commitPart(std::shared_ptr const&, std::shared_ptr&, String const&, unsigned long)::'lambda3'()>(DB::ReplicatedMergeTreeSinkImpl::commitPart(std::shared_ptr const&, std::shared_ptr&, String const&, unsigned long)::'lambda3'()&&)::'lambda'()&&) @ 0x000000001660d07f 11. /build/src/Common/ZooKeeper/ZooKeeperRetries.h:52: DB::ReplicatedMergeTreeSinkImpl::commitPart(std::shared_ptr const&, std::shared_ptr&, String const&, unsigned long) @ 0x00000000165fd951 12. /build/src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:492: DB::ReplicatedMergeTreeSinkImpl::finishDelayedChunk(std::shared_ptr const&) @ 0x00000000165f277d 13. /build/src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:1235: DB::ReplicatedMergeTreeSinkImpl::onFinish() @ 0x00000000165fd175 14. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000016c0abf5 15. /build/src/Processors/Transforms/ExceptionKeepingTransform.cpp:187: DB::ExceptionKeepingTransform::work() @ 0x0000000016c0a7bc 16. /build/src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x00000000169bd00f 17. /build/src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x00000000169b2105 18. /build/src/Processors/Executors/PipelineExecutor.cpp:170: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x00000000169b16a7 19. /build/src/Processors/Executors/PushingPipelineExecutor.cpp:131: DB::PushingPipelineExecutor::finish() @ 0x00000000169c359f 20. /build/src/Server/TCPHandler.cpp:1128: DB::TCPHandler::processInsertQuery(DB::QueryState&) @ 0x00000000168f0d2c 21. /build/src/Server/TCPHandler.cpp:673: DB::TCPHandler::runImpl() @ 0x00000000168e68bc 22. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 23. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 24. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 25. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 26. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 27. ? @ 0x00007fbc6213eac3 28. ? @ 0x00007fbc621d0850 2025.07.28 11:51:06.382673 [ 12807 ] {f1a67335-e2fe-438c-ba82-6b34622089e3} executeQuery: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=818, jobs=782). (CANNOT_SCHEDULE_TASK) (version 25.3.6.10636.altinitytest (altinity build)) (from [::1]:58338) (comment: 03202_dynamic_null_map_subcolumn.gen.sql) (query 30, line 38) (in query: select d.Int8.null, d.Date.null, d.`Array(String)`.null from test format Null;), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000fccaeeb 4. /build/src/Common/ThreadPool.cpp:275: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000fccacb3 5. /build/src/Common/ThreadPool.cpp:323: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fcc4ffc 6. /build/src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000000fcc584d 7. /build/src/Common/ThreadPool.h:279: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x00000000169bf193 8. /build/src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x00000000169bf518 9. /build/src/Server/TCPHandler.cpp:1237: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x00000000168f1525 10. /build/src/Server/TCPHandler.cpp:678: DB::TCPHandler::runImpl() @ 0x00000000168e68e5 11. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 12. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 13. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 14. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 15. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 16. ? @ 0x00007fbc6213eac3 17. ? @ 0x00007fbc621d0850 2025.07.28 11:51:06.393959 [ 12807 ] {} TCPHandler: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=818, jobs=782). (CANNOT_SCHEDULE_TASK), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000fccaeeb 4. /build/src/Common/ThreadPool.cpp:275: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000fccacb3 5. /build/src/Common/ThreadPool.cpp:323: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fcc4ffc 6. /build/src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000000fcc584d 7. /build/src/Common/ThreadPool.h:279: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x00000000169bf193 8. /build/src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x00000000169bf518 9. /build/src/Server/TCPHandler.cpp:1237: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x00000000168f1525 10. /build/src/Server/TCPHandler.cpp:678: DB::TCPHandler::runImpl() @ 0x00000000168e68e5 11. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 12. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 13. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 14. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 15. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 16. ? @ 0x00007fbc6213eac3 17. ? @ 0x00007fbc621d0850 2025.07.28 11:51:07.382838 [ 11826 ] {d3491388-7e48-4fee-b1af-181cbee2c200} 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.6.10636.altinitytest (altinity build)) (from [::1]:50820) (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. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&) @ 0x000000000a10182b 4. /build/src/DataTypes/DataTypesDecimal.cpp:134: void DB::convertDecimalsImpl>, DB::DataTypeDecimal>, void>(T::FieldType const&, unsigned int, unsigned int, T0::FieldType&) @ 0x0000000013c20431 5. /build/src/DataTypes/DataTypesDecimal.cpp:184: T0::FieldType DB::convertDecimals>, DB::DataTypeDecimal>>(T::FieldType const&, unsigned int, unsigned int) @ 0x0000000013c266e9 6. /build/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) @ 0x0000000013125eba 7. /build/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 @ 0x00000000131174a4 8. /build/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&&) @ 0x0000000012fad4d9 9. /build/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 @ 0x0000000012fcf80e 10. /build/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 @ 0x0000000012fcf03a 11. /build/src/Functions/IFunction.h:437: DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000a069f2a 12. /build/src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000012d9965a 13. /build/src/Functions/IFunction.cpp:351: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d93b02 14. /build/src/Functions/IFunction.cpp:177: DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d93698 15. /build/src/Functions/IFunction.cpp:343: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d93aad 16. /build/src/Functions/IFunction.cpp:420: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d95059 17. /build/src/Functions/IFunction.cpp:498: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d95c72 18. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3567: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000014034494 19. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3838: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000014019a9e 20. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3980: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000014018e31 21. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:4304: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000014042fa7 22. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5605: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000014013749 23. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000140127f9 24. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000014011fce 25. /build/src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000001406ce8a 26. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000014973b42 27. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000001497268d 28. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000014974d24 29. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001492924b 30. /build/src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88641 31. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 2025.07.28 11:51:07.386033 [ 11826 ] {} 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. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&) @ 0x000000000a10182b 4. /build/src/DataTypes/DataTypesDecimal.cpp:134: void DB::convertDecimalsImpl>, DB::DataTypeDecimal>, void>(T::FieldType const&, unsigned int, unsigned int, T0::FieldType&) @ 0x0000000013c20431 5. /build/src/DataTypes/DataTypesDecimal.cpp:184: T0::FieldType DB::convertDecimals>, DB::DataTypeDecimal>>(T::FieldType const&, unsigned int, unsigned int) @ 0x0000000013c266e9 6. /build/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) @ 0x0000000013125eba 7. /build/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 @ 0x00000000131174a4 8. /build/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&&) @ 0x0000000012fad4d9 9. /build/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 @ 0x0000000012fcf80e 10. /build/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 @ 0x0000000012fcf03a 11. /build/src/Functions/IFunction.h:437: DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000a069f2a 12. /build/src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000012d9965a 13. /build/src/Functions/IFunction.cpp:351: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d93b02 14. /build/src/Functions/IFunction.cpp:177: DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d93698 15. /build/src/Functions/IFunction.cpp:343: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d93aad 16. /build/src/Functions/IFunction.cpp:420: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d95059 17. /build/src/Functions/IFunction.cpp:498: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d95c72 18. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3567: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000014034494 19. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3838: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000014019a9e 20. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3980: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000014018e31 21. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:4304: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000014042fa7 22. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5605: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000014013749 23. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000140127f9 24. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000014011fce 25. /build/src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000001406ce8a 26. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000014973b42 27. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000001497268d 28. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000014974d24 29. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001492924b 30. /build/src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88641 31. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 2025.07.28 11:51:07.605271 [ 5327 ] {35a17309-853b-4af4-8082-66d4478e3114} executeQuery: Code: 999. DB::Exception: Fault injection before operation. (KEEPER_EXCEPTION) (version 25.3.6.10636.altinitytest (altinity build)) (from [::1]:50632) (comment: 02456_keeper_retries_during_insert.sql) (query 7, line 11) (in query: INSERT INTO keeper_retries_r1 SETTINGS insert_keeper_fault_injection_probability=1, insert_keeper_retry_max_backoff_ms=10 VALUES ), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: Coordination::Exception::Exception(T&&, Coordination::Error) @ 0x000000001719535e 3. /build/src/Common/ZooKeeper/KeeperException.h:58: Coordination::Exception Coordination::Exception::fromMessage(Coordination::Error, T&&) @ 0x0000000017193090 4. /build/src/Common/ZooKeeper/ZooKeeperWithFaultInjection.cpp:107: DB::ZooKeeperWithFaultInjection::injectFailureBeforeOperationThrow(char const*, String const&) @ 0x000000001718d587 5. /build/src/Common/ZooKeeper/ZooKeeperWithFaultInjection.cpp:134: DB::ZooKeeperWithFaultInjection::exists(String const&, Coordination::Stat*, std::shared_ptr const&) @ 0x000000001718ece7 6. /build/src/Storages/StorageReplicatedMergeTree.cpp:7078: DB::StorageReplicatedMergeTree::existsNodeCached(std::shared_ptr const&, String const&) const @ 0x0000000015e85d42 7. /build/src/Storages/StorageReplicatedMergeTree.cpp:7115: std::optional DB::StorageReplicatedMergeTree::allocateBlockNumber(String const&, std::shared_ptr const&, String const&, String const&) const @ 0x0000000015f9da3c 8. /build/src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:898: DB::ReplicatedMergeTreeSinkImpl::commitPart(std::shared_ptr const&, std::shared_ptr&, String const&, unsigned long)::'lambda1'()::operator()() const @ 0x000000001660d433 9. /build/src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:1124: DB::ReplicatedMergeTreeSinkImpl::commitPart(std::shared_ptr const&, std::shared_ptr&, String const&, unsigned long)::'lambda2'()::operator()() const @ 0x000000001660d1f2 10. /build/src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:1157: void DB::ZooKeeperRetriesControl::retryLoop::commitPart(std::shared_ptr const&, std::shared_ptr&, String const&, unsigned long)::'lambda3'()&, void DB::ZooKeeperRetriesControl::retryLoop::commitPart(std::shared_ptr const&, std::shared_ptr&, String const&, unsigned long)::'lambda3'()>(DB::ReplicatedMergeTreeSinkImpl::commitPart(std::shared_ptr const&, std::shared_ptr&, String const&, unsigned long)::'lambda3'()&&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::commitPart(std::shared_ptr const&, std::shared_ptr&, String const&, unsigned long)::'lambda3'()&&, void DB::ZooKeeperRetriesControl::retryLoop::commitPart(std::shared_ptr const&, std::shared_ptr&, String const&, unsigned long)::'lambda3'()>(DB::ReplicatedMergeTreeSinkImpl::commitPart(std::shared_ptr const&, std::shared_ptr&, String const&, unsigned long)::'lambda3'()&&)::'lambda'()&&) @ 0x000000001660d07f 11. /build/src/Common/ZooKeeper/ZooKeeperRetries.h:52: DB::ReplicatedMergeTreeSinkImpl::commitPart(std::shared_ptr const&, std::shared_ptr&, String const&, unsigned long) @ 0x00000000165fd951 12. /build/src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:492: DB::ReplicatedMergeTreeSinkImpl::finishDelayedChunk(std::shared_ptr const&) @ 0x00000000165f277d 13. /build/src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:1235: DB::ReplicatedMergeTreeSinkImpl::onFinish() @ 0x00000000165fd175 14. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000016c0abf5 15. /build/src/Processors/Transforms/ExceptionKeepingTransform.cpp:187: DB::ExceptionKeepingTransform::work() @ 0x0000000016c0a7bc 16. /build/src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x00000000169bd00f 17. /build/src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x00000000169b2105 18. /build/src/Processors/Executors/PipelineExecutor.cpp:170: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x00000000169b16a7 19. /build/src/Processors/Executors/PushingPipelineExecutor.cpp:131: DB::PushingPipelineExecutor::finish() @ 0x00000000169c359f 20. /build/src/Server/TCPHandler.cpp:1128: DB::TCPHandler::processInsertQuery(DB::QueryState&) @ 0x00000000168f0d2c 21. /build/src/Server/TCPHandler.cpp:673: DB::TCPHandler::runImpl() @ 0x00000000168e68bc 22. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 23. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 24. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 25. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 26. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 27. ? @ 0x00007fbc6213eac3 28. ? @ 0x00007fbc621d0850 2025.07.28 11:51:07.612247 [ 5327 ] {} TCPHandler: Code: 999. Coordination::Exception: Fault injection before operation. (KEEPER_EXCEPTION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: Coordination::Exception::Exception(T&&, Coordination::Error) @ 0x000000001719535e 3. /build/src/Common/ZooKeeper/KeeperException.h:58: Coordination::Exception Coordination::Exception::fromMessage(Coordination::Error, T&&) @ 0x0000000017193090 4. /build/src/Common/ZooKeeper/ZooKeeperWithFaultInjection.cpp:107: DB::ZooKeeperWithFaultInjection::injectFailureBeforeOperationThrow(char const*, String const&) @ 0x000000001718d587 5. /build/src/Common/ZooKeeper/ZooKeeperWithFaultInjection.cpp:134: DB::ZooKeeperWithFaultInjection::exists(String const&, Coordination::Stat*, std::shared_ptr const&) @ 0x000000001718ece7 6. /build/src/Storages/StorageReplicatedMergeTree.cpp:7078: DB::StorageReplicatedMergeTree::existsNodeCached(std::shared_ptr const&, String const&) const @ 0x0000000015e85d42 7. /build/src/Storages/StorageReplicatedMergeTree.cpp:7115: std::optional DB::StorageReplicatedMergeTree::allocateBlockNumber(String const&, std::shared_ptr const&, String const&, String const&) const @ 0x0000000015f9da3c 8. /build/src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:898: DB::ReplicatedMergeTreeSinkImpl::commitPart(std::shared_ptr const&, std::shared_ptr&, String const&, unsigned long)::'lambda1'()::operator()() const @ 0x000000001660d433 9. /build/src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:1124: DB::ReplicatedMergeTreeSinkImpl::commitPart(std::shared_ptr const&, std::shared_ptr&, String const&, unsigned long)::'lambda2'()::operator()() const @ 0x000000001660d1f2 10. /build/src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:1157: void DB::ZooKeeperRetriesControl::retryLoop::commitPart(std::shared_ptr const&, std::shared_ptr&, String const&, unsigned long)::'lambda3'()&, void DB::ZooKeeperRetriesControl::retryLoop::commitPart(std::shared_ptr const&, std::shared_ptr&, String const&, unsigned long)::'lambda3'()>(DB::ReplicatedMergeTreeSinkImpl::commitPart(std::shared_ptr const&, std::shared_ptr&, String const&, unsigned long)::'lambda3'()&&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::commitPart(std::shared_ptr const&, std::shared_ptr&, String const&, unsigned long)::'lambda3'()&&, void DB::ZooKeeperRetriesControl::retryLoop::commitPart(std::shared_ptr const&, std::shared_ptr&, String const&, unsigned long)::'lambda3'()>(DB::ReplicatedMergeTreeSinkImpl::commitPart(std::shared_ptr const&, std::shared_ptr&, String const&, unsigned long)::'lambda3'()&&)::'lambda'()&&) @ 0x000000001660d07f 11. /build/src/Common/ZooKeeper/ZooKeeperRetries.h:52: DB::ReplicatedMergeTreeSinkImpl::commitPart(std::shared_ptr const&, std::shared_ptr&, String const&, unsigned long) @ 0x00000000165fd951 12. /build/src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:492: DB::ReplicatedMergeTreeSinkImpl::finishDelayedChunk(std::shared_ptr const&) @ 0x00000000165f277d 13. /build/src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:1235: DB::ReplicatedMergeTreeSinkImpl::onFinish() @ 0x00000000165fd175 14. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000016c0abf5 15. /build/src/Processors/Transforms/ExceptionKeepingTransform.cpp:187: DB::ExceptionKeepingTransform::work() @ 0x0000000016c0a7bc 16. /build/src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x00000000169bd00f 17. /build/src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x00000000169b2105 18. /build/src/Processors/Executors/PipelineExecutor.cpp:170: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x00000000169b16a7 19. /build/src/Processors/Executors/PushingPipelineExecutor.cpp:131: DB::PushingPipelineExecutor::finish() @ 0x00000000169c359f 20. /build/src/Server/TCPHandler.cpp:1128: DB::TCPHandler::processInsertQuery(DB::QueryState&) @ 0x00000000168f0d2c 21. /build/src/Server/TCPHandler.cpp:673: DB::TCPHandler::runImpl() @ 0x00000000168e68bc 22. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 23. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 24. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 25. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 26. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 27. ? @ 0x00007fbc6213eac3 28. ? @ 0x00007fbc621d0850 2025.07.28 11:51:07.799654 [ 11826 ] {291e24ed-70fd-409a-bfc6-3a3ea97b3070} 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.6.10636.altinitytest (altinity build)) (from [::1]:50820) (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. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&) @ 0x000000000a10182b 4. /build/src/DataTypes/DataTypesDecimal.cpp:134: void DB::convertDecimalsImpl>, DB::DataTypeDecimal>, void>(T::FieldType const&, unsigned int, unsigned int, T0::FieldType&) @ 0x0000000013c1e38c 5. /build/src/DataTypes/DataTypesDecimal.cpp:184: T0::FieldType DB::convertDecimals>, DB::DataTypeDecimal>>(T::FieldType const&, unsigned int, unsigned int) @ 0x0000000013c2662b 6. /build/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) @ 0x000000001310cb9a 7. /build/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 @ 0x00000000130feb04 8. /build/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&&) @ 0x0000000012fad0e9 9. /build/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 @ 0x0000000012fce44e 10. /build/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 @ 0x0000000012fcdc7a 11. /build/src/Functions/IFunction.h:437: DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000a069f2a 12. /build/src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000012d9965a 13. /build/src/Functions/IFunction.cpp:351: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d93b02 14. /build/src/Functions/IFunction.cpp:177: DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d93698 15. /build/src/Functions/IFunction.cpp:343: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d93aad 16. /build/src/Functions/IFunction.cpp:420: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d95059 17. /build/src/Functions/IFunction.cpp:498: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d95c72 18. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3567: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000014034494 19. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3838: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000014019a9e 20. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3980: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000014018e31 21. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:4304: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000014042fa7 22. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5605: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000014013749 23. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000140127f9 24. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000014011fce 25. /build/src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000001406ce8a 26. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000014973b42 27. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000001497268d 28. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000014974d24 29. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001492924b 30. /build/src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88641 31. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 2025.07.28 11:51:07.804590 [ 11826 ] {} 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. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&) @ 0x000000000a10182b 4. /build/src/DataTypes/DataTypesDecimal.cpp:134: void DB::convertDecimalsImpl>, DB::DataTypeDecimal>, void>(T::FieldType const&, unsigned int, unsigned int, T0::FieldType&) @ 0x0000000013c1e38c 5. /build/src/DataTypes/DataTypesDecimal.cpp:184: T0::FieldType DB::convertDecimals>, DB::DataTypeDecimal>>(T::FieldType const&, unsigned int, unsigned int) @ 0x0000000013c2662b 6. /build/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) @ 0x000000001310cb9a 7. /build/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 @ 0x00000000130feb04 8. /build/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&&) @ 0x0000000012fad0e9 9. /build/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 @ 0x0000000012fce44e 10. /build/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 @ 0x0000000012fcdc7a 11. /build/src/Functions/IFunction.h:437: DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000a069f2a 12. /build/src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000012d9965a 13. /build/src/Functions/IFunction.cpp:351: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d93b02 14. /build/src/Functions/IFunction.cpp:177: DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d93698 15. /build/src/Functions/IFunction.cpp:343: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d93aad 16. /build/src/Functions/IFunction.cpp:420: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d95059 17. /build/src/Functions/IFunction.cpp:498: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d95c72 18. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3567: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000014034494 19. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3838: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000014019a9e 20. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3980: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000014018e31 21. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:4304: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000014042fa7 22. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5605: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000014013749 23. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000140127f9 24. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000014011fce 25. /build/src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000001406ce8a 26. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000014973b42 27. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000001497268d 28. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000014974d24 29. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001492924b 30. /build/src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88641 31. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 2025.07.28 11:51:07.898482 [ 11826 ] {56c5687c-b0e3-4f68-8349-27bbe723a5d4} 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.6.10636.altinitytest (altinity build)) (from [::1]:50820) (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. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&) @ 0x000000000a10182b 4. /build/src/DataTypes/DataTypesDecimal.cpp:134: void DB::convertDecimalsImpl>, DB::DataTypeDecimal>, void>(T::FieldType const&, unsigned int, unsigned int, T0::FieldType&) @ 0x0000000013c20431 5. /build/src/DataTypes/DataTypesDecimal.cpp:184: T0::FieldType DB::convertDecimals>, DB::DataTypeDecimal>>(T::FieldType const&, unsigned int, unsigned int) @ 0x0000000013c266e9 6. /build/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) @ 0x0000000013125eba 7. /build/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 @ 0x00000000131174a4 8. /build/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&&) @ 0x0000000012fad4d9 9. /build/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 @ 0x0000000012fcf80e 10. /build/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 @ 0x0000000012fcf03a 11. /build/src/Functions/IFunction.h:437: DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000a069f2a 12. /build/src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000012d9965a 13. /build/src/Functions/IFunction.cpp:351: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d93b02 14. /build/src/Functions/IFunction.cpp:177: DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d93698 15. /build/src/Functions/IFunction.cpp:343: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d93aad 16. /build/src/Functions/IFunction.cpp:420: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d95059 17. /build/src/Functions/IFunction.cpp:498: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d95c72 18. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3567: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000014034494 19. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3838: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000014019a9e 20. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3980: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000014018e31 21. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:4304: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000014042fa7 22. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5605: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000014013749 23. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000140127f9 24. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000014011fce 25. /build/src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000001406ce8a 26. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000014973b42 27. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000001497268d 28. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000014974d24 29. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001492924b 30. /build/src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88641 31. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 2025.07.28 11:51:07.913031 [ 11826 ] {} 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. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&) @ 0x000000000a10182b 4. /build/src/DataTypes/DataTypesDecimal.cpp:134: void DB::convertDecimalsImpl>, DB::DataTypeDecimal>, void>(T::FieldType const&, unsigned int, unsigned int, T0::FieldType&) @ 0x0000000013c20431 5. /build/src/DataTypes/DataTypesDecimal.cpp:184: T0::FieldType DB::convertDecimals>, DB::DataTypeDecimal>>(T::FieldType const&, unsigned int, unsigned int) @ 0x0000000013c266e9 6. /build/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) @ 0x0000000013125eba 7. /build/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 @ 0x00000000131174a4 8. /build/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&&) @ 0x0000000012fad4d9 9. /build/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 @ 0x0000000012fcf80e 10. /build/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 @ 0x0000000012fcf03a 11. /build/src/Functions/IFunction.h:437: DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000a069f2a 12. /build/src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000012d9965a 13. /build/src/Functions/IFunction.cpp:351: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d93b02 14. /build/src/Functions/IFunction.cpp:177: DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d93698 15. /build/src/Functions/IFunction.cpp:343: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d93aad 16. /build/src/Functions/IFunction.cpp:420: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d95059 17. /build/src/Functions/IFunction.cpp:498: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d95c72 18. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3567: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000014034494 19. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3838: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000014019a9e 20. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3980: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000014018e31 21. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:4304: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000014042fa7 22. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5605: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000014013749 23. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000140127f9 24. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000014011fce 25. /build/src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000001406ce8a 26. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000014973b42 27. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000001497268d 28. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000014974d24 29. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001492924b 30. /build/src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88641 31. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 2025.07.28 11:51:07.951774 [ 11826 ] {8c35bcb4-1742-465e-bc9f-1a01d35726bd} 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.6.10636.altinitytest (altinity build)) (from [::1]:50820) (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. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&) @ 0x000000000a10182b 4. /build/src/DataTypes/DataTypesDecimal.cpp:134: void DB::convertDecimalsImpl>, DB::DataTypeDecimal>, void>(T::FieldType const&, unsigned int, unsigned int, T0::FieldType&) @ 0x0000000013c20431 5. /build/src/DataTypes/DataTypesDecimal.cpp:184: T0::FieldType DB::convertDecimals>, DB::DataTypeDecimal>>(T::FieldType const&, unsigned int, unsigned int) @ 0x0000000013c266e9 6. /build/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) @ 0x0000000013125eba 7. /build/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 @ 0x00000000131174a4 8. /build/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&&) @ 0x0000000012fad4d9 9. /build/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 @ 0x0000000012fcf80e 10. /build/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 @ 0x0000000012fcf03a 11. /build/src/Functions/IFunction.h:437: DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000a069f2a 12. /build/src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000012d9965a 13. /build/src/Functions/IFunction.cpp:351: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d93b02 14. /build/src/Functions/IFunction.cpp:177: DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d93698 15. /build/src/Functions/IFunction.cpp:343: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d93aad 16. /build/src/Functions/IFunction.cpp:420: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d95059 17. /build/src/Functions/IFunction.cpp:498: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d95c72 18. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3567: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000014034494 19. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3838: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000014019a9e 20. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3980: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000014018e31 21. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:4304: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000014042fa7 22. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5605: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000014013749 23. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000140127f9 24. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000014011fce 25. /build/src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000001406ce8a 26. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000014973b42 27. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000001497268d 28. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000014974d24 29. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001492924b 30. /build/src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88641 31. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 2025.07.28 11:51:07.954712 [ 11826 ] {} 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. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&) @ 0x000000000a10182b 4. /build/src/DataTypes/DataTypesDecimal.cpp:134: void DB::convertDecimalsImpl>, DB::DataTypeDecimal>, void>(T::FieldType const&, unsigned int, unsigned int, T0::FieldType&) @ 0x0000000013c20431 5. /build/src/DataTypes/DataTypesDecimal.cpp:184: T0::FieldType DB::convertDecimals>, DB::DataTypeDecimal>>(T::FieldType const&, unsigned int, unsigned int) @ 0x0000000013c266e9 6. /build/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) @ 0x0000000013125eba 7. /build/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 @ 0x00000000131174a4 8. /build/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&&) @ 0x0000000012fad4d9 9. /build/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 @ 0x0000000012fcf80e 10. /build/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 @ 0x0000000012fcf03a 11. /build/src/Functions/IFunction.h:437: DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000a069f2a 12. /build/src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000012d9965a 13. /build/src/Functions/IFunction.cpp:351: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d93b02 14. /build/src/Functions/IFunction.cpp:177: DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d93698 15. /build/src/Functions/IFunction.cpp:343: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d93aad 16. /build/src/Functions/IFunction.cpp:420: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d95059 17. /build/src/Functions/IFunction.cpp:498: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d95c72 18. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3567: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000014034494 19. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3838: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000014019a9e 20. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3980: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000014018e31 21. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:4304: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000014042fa7 22. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5605: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000014013749 23. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000140127f9 24. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000014011fce 25. /build/src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000001406ce8a 26. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000014973b42 27. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000001497268d 28. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000014974d24 29. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001492924b 30. /build/src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88641 31. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 2025.07.28 11:51:08.256965 [ 5327 ] {d7434243-40de-4d90-adaa-a76036147ca0} executeQuery: Code: 999. DB::Exception: Fault injection before operation. (KEEPER_EXCEPTION) (version 25.3.6.10636.altinitytest (altinity build)) (from [::1]:50632) (comment: 02456_keeper_retries_during_insert.sql) (query 10, line 15) (in query: INSERT INTO keeper_retries_r1 SETTINGS insert_keeper_fault_injection_probability=1, insert_keeper_max_retries=0 VALUES ), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: Coordination::Exception::Exception(T&&, Coordination::Error) @ 0x000000001719535e 3. /build/src/Common/ZooKeeper/KeeperException.h:58: Coordination::Exception Coordination::Exception::fromMessage(Coordination::Error, T&&) @ 0x0000000017193090 4. /build/src/Common/ZooKeeper/ZooKeeperWithFaultInjection.cpp:107: DB::ZooKeeperWithFaultInjection::injectFailureBeforeOperationThrow(char const*, String const&) @ 0x000000001718d587 5. /build/src/Common/ZooKeeper/ZooKeeperWithFaultInjection.cpp:134: DB::ZooKeeperWithFaultInjection::getChildren(String const&, Coordination::Stat*, std::shared_ptr const&, Coordination::ListRequestType) @ 0x000000001718e22c 6. /build/src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:226: DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()::operator()() const @ 0x000000001660b90f 7. /build/src/Common/ZooKeeper/ZooKeeperRetries.h:78: void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&, void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&, void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&)::'lambda'()&&) @ 0x000000001660b538 8. /build/src/Common/ZooKeeper/ZooKeeperRetries.h:52: DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&) @ 0x00000000165fcf49 9. /build/src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:316: DB::ReplicatedMergeTreeSinkImpl::consume(DB::Chunk&) @ 0x00000000165fae3a 10. /build/src/Processors/Sinks/SinkToStorage.cpp:10: DB::SinkToStorage::onConsume(DB::Chunk) @ 0x0000000016cee093 11. /build/src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: void std::__function::__policy_invoker::__call_impl[abi:se190107]>(std::__function::__policy_storage const*) @ 0x0000000016c0ad89 12. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000016c0abf5 13. /build/src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: DB::ExceptionKeepingTransform::work() @ 0x0000000016c0a6fe 14. /build/src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x00000000169bd00f 15. /build/src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x00000000169b2105 16. /build/src/Processors/Executors/PipelineExecutor.cpp:170: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x00000000169b16a7 17. /build/src/Processors/Executors/PushingPipelineExecutor.cpp:131: DB::PushingPipelineExecutor::finish() @ 0x00000000169c359f 18. /build/src/Server/TCPHandler.cpp:1128: DB::TCPHandler::processInsertQuery(DB::QueryState&) @ 0x00000000168f0d2c 19. /build/src/Server/TCPHandler.cpp:673: DB::TCPHandler::runImpl() @ 0x00000000168e68bc 20. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 21. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 22. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 23. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 24. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 25. ? @ 0x00007fbc6213eac3 26. ? @ 0x00007fbc621d0850 2025.07.28 11:51:08.260595 [ 5327 ] {} TCPHandler: Code: 999. Coordination::Exception: Fault injection before operation. (KEEPER_EXCEPTION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: Coordination::Exception::Exception(T&&, Coordination::Error) @ 0x000000001719535e 3. /build/src/Common/ZooKeeper/KeeperException.h:58: Coordination::Exception Coordination::Exception::fromMessage(Coordination::Error, T&&) @ 0x0000000017193090 4. /build/src/Common/ZooKeeper/ZooKeeperWithFaultInjection.cpp:107: DB::ZooKeeperWithFaultInjection::injectFailureBeforeOperationThrow(char const*, String const&) @ 0x000000001718d587 5. /build/src/Common/ZooKeeper/ZooKeeperWithFaultInjection.cpp:134: DB::ZooKeeperWithFaultInjection::getChildren(String const&, Coordination::Stat*, std::shared_ptr const&, Coordination::ListRequestType) @ 0x000000001718e22c 6. /build/src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:226: DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()::operator()() const @ 0x000000001660b90f 7. /build/src/Common/ZooKeeper/ZooKeeperRetries.h:78: void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&, void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&, void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&)::'lambda'()&&) @ 0x000000001660b538 8. /build/src/Common/ZooKeeper/ZooKeeperRetries.h:52: DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&) @ 0x00000000165fcf49 9. /build/src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:316: DB::ReplicatedMergeTreeSinkImpl::consume(DB::Chunk&) @ 0x00000000165fae3a 10. /build/src/Processors/Sinks/SinkToStorage.cpp:10: DB::SinkToStorage::onConsume(DB::Chunk) @ 0x0000000016cee093 11. /build/src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: void std::__function::__policy_invoker::__call_impl[abi:se190107]>(std::__function::__policy_storage const*) @ 0x0000000016c0ad89 12. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000016c0abf5 13. /build/src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: DB::ExceptionKeepingTransform::work() @ 0x0000000016c0a6fe 14. /build/src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x00000000169bd00f 15. /build/src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x00000000169b2105 16. /build/src/Processors/Executors/PipelineExecutor.cpp:170: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x00000000169b16a7 17. /build/src/Processors/Executors/PushingPipelineExecutor.cpp:131: DB::PushingPipelineExecutor::finish() @ 0x00000000169c359f 18. /build/src/Server/TCPHandler.cpp:1128: DB::TCPHandler::processInsertQuery(DB::QueryState&) @ 0x00000000168f0d2c 19. /build/src/Server/TCPHandler.cpp:673: DB::TCPHandler::runImpl() @ 0x00000000168e68bc 20. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 21. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 22. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 23. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 24. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 25. ? @ 0x00007fbc6213eac3 26. ? @ 0x00007fbc621d0850 2025.07.28 11:51:08.320243 [ 11826 ] {1ec87b09-a548-46f2-bff7-b67cde359c59} executeQuery: Code: 407. DB::Exception: Convert overflow: In scope SELECT toDecimal128('9223372036854775809', 6) AS x, toInt64(x). (DECIMAL_OVERFLOW) (version 25.3.6.10636.altinitytest (altinity build)) (from [::1]:50820) (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. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000000a074fcb 4. /build/src/Core/DecimalFunctions.h:354: void DB::DecimalUtils::convertToImpl>, void>(DB::Decimal> const&, unsigned int, long&) @ 0x0000000013c2b48c 5. /build/src/DataTypes/DataTypesDecimal.cpp:217: T0::FieldType DB::convertFromDecimal>>, DB::DataTypeNumber>(T::FieldType const&, unsigned int) @ 0x0000000013c2eb29 6. /build/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*) @ 0x000000001302c342 7. /build/src/Functions/FunctionsConversion.h:2467: 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&&) @ 0x0000000012fa2984 8. /build/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 @ 0x0000000012fb980e 9. /build/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 @ 0x0000000012fb903a 10. /build/src/Functions/IFunction.h:437: DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000a069f2a 11. /build/src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000012d9965a 12. /build/src/Functions/IFunction.cpp:351: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d93b02 13. /build/src/Functions/IFunction.cpp:177: DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d93698 14. /build/src/Functions/IFunction.cpp:343: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d93aad 15. /build/src/Functions/IFunction.cpp:420: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d95059 16. /build/src/Functions/IFunction.cpp:498: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d95c72 17. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3567: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000014034494 18. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3838: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000014019a9e 19. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3980: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000014018e31 20. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:4304: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000014042fa7 21. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5605: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000014013749 22. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000140127f9 23. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000014011fce 24. /build/src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000001406ce8a 25. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000014973b42 26. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000001497268d 27. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000014974d24 28. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001492924b 29. /build/src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88641 30. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 31. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 2025.07.28 11:51:08.324231 [ 11826 ] {} 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. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000000a074fcb 4. /build/src/Core/DecimalFunctions.h:354: void DB::DecimalUtils::convertToImpl>, void>(DB::Decimal> const&, unsigned int, long&) @ 0x0000000013c2b48c 5. /build/src/DataTypes/DataTypesDecimal.cpp:217: T0::FieldType DB::convertFromDecimal>>, DB::DataTypeNumber>(T::FieldType const&, unsigned int) @ 0x0000000013c2eb29 6. /build/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*) @ 0x000000001302c342 7. /build/src/Functions/FunctionsConversion.h:2467: 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&&) @ 0x0000000012fa2984 8. /build/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 @ 0x0000000012fb980e 9. /build/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 @ 0x0000000012fb903a 10. /build/src/Functions/IFunction.h:437: DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000a069f2a 11. /build/src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000012d9965a 12. /build/src/Functions/IFunction.cpp:351: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d93b02 13. /build/src/Functions/IFunction.cpp:177: DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d93698 14. /build/src/Functions/IFunction.cpp:343: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d93aad 15. /build/src/Functions/IFunction.cpp:420: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d95059 16. /build/src/Functions/IFunction.cpp:498: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d95c72 17. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3567: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000014034494 18. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3838: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000014019a9e 19. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3980: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000014018e31 20. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:4304: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000014042fa7 21. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5605: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000014013749 22. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000140127f9 23. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000014011fce 24. /build/src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000001406ce8a 25. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000014973b42 26. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000001497268d 27. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000014974d24 28. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001492924b 29. /build/src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88641 30. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 31. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 2025.07.28 11:51:08.490170 [ 11826 ] {4a0d59db-9afa-431e-8d4f-0384f96d50b9} executeQuery: Code: 407. DB::Exception: Convert overflow: In scope SELECT toDecimal128('9223372036854775809', 6) AS x, toInt64(-x). (DECIMAL_OVERFLOW) (version 25.3.6.10636.altinitytest (altinity build)) (from [::1]:50820) (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. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000000a074fcb 4. /build/src/Core/DecimalFunctions.h:354: void DB::DecimalUtils::convertToImpl>, void>(DB::Decimal> const&, unsigned int, long&) @ 0x0000000013c2b48c 5. /build/src/DataTypes/DataTypesDecimal.cpp:217: T0::FieldType DB::convertFromDecimal>>, DB::DataTypeNumber>(T::FieldType const&, unsigned int) @ 0x0000000013c2eb29 6. /build/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*) @ 0x000000001302c342 7. /build/src/Functions/FunctionsConversion.h:2467: 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&&) @ 0x0000000012fa2984 8. /build/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 @ 0x0000000012fb980e 9. /build/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 @ 0x0000000012fb903a 10. /build/src/Functions/IFunction.h:437: DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000a069f2a 11. /build/src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000012d9965a 12. /build/src/Functions/IFunction.cpp:351: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d93b02 13. /build/src/Functions/IFunction.cpp:177: DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d93698 14. /build/src/Functions/IFunction.cpp:343: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d93aad 15. /build/src/Functions/IFunction.cpp:420: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d95059 16. /build/src/Functions/IFunction.cpp:498: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d95c72 17. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3567: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000014034494 18. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3838: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000014019a9e 19. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3980: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000014018e31 20. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:4304: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000014042fa7 21. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5605: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000014013749 22. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000140127f9 23. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000014011fce 24. /build/src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000001406ce8a 25. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000014973b42 26. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000001497268d 27. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000014974d24 28. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001492924b 29. /build/src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88641 30. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 31. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 2025.07.28 11:51:08.499375 [ 11826 ] {} 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. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000000a074fcb 4. /build/src/Core/DecimalFunctions.h:354: void DB::DecimalUtils::convertToImpl>, void>(DB::Decimal> const&, unsigned int, long&) @ 0x0000000013c2b48c 5. /build/src/DataTypes/DataTypesDecimal.cpp:217: T0::FieldType DB::convertFromDecimal>>, DB::DataTypeNumber>(T::FieldType const&, unsigned int) @ 0x0000000013c2eb29 6. /build/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*) @ 0x000000001302c342 7. /build/src/Functions/FunctionsConversion.h:2467: 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&&) @ 0x0000000012fa2984 8. /build/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 @ 0x0000000012fb980e 9. /build/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 @ 0x0000000012fb903a 10. /build/src/Functions/IFunction.h:437: DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000a069f2a 11. /build/src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000012d9965a 12. /build/src/Functions/IFunction.cpp:351: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d93b02 13. /build/src/Functions/IFunction.cpp:177: DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d93698 14. /build/src/Functions/IFunction.cpp:343: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d93aad 15. /build/src/Functions/IFunction.cpp:420: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d95059 16. /build/src/Functions/IFunction.cpp:498: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d95c72 17. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3567: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000014034494 18. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3838: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000014019a9e 19. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3980: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000014018e31 20. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:4304: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000014042fa7 21. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5605: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000014013749 22. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000140127f9 23. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000014011fce 24. /build/src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000001406ce8a 25. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000014973b42 26. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000001497268d 27. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000014974d24 28. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001492924b 29. /build/src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88641 30. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 31. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 2025.07.28 11:51:09.240274 [ 11826 ] {babc666c-644c-40d6-8ec4-40a8294e7c48} executeQuery: Code: 407. DB::Exception: Convert overflow: In scope SELECT toDecimal128('2147483649', 10) AS x, toInt32(x), toInt32(-x). (DECIMAL_OVERFLOW) (version 25.3.6.10636.altinitytest (altinity build)) (from [::1]:50820) (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. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000000a074fcb 4. /build/src/Core/DecimalFunctions.h:354: void DB::DecimalUtils::convertToImpl>, void>(DB::Decimal> const&, unsigned int, int&) @ 0x0000000013c285eb 5. /build/src/DataTypes/DataTypesDecimal.cpp:217: T0::FieldType DB::convertFromDecimal>>, DB::DataTypeNumber>(T::FieldType const&, unsigned int) @ 0x0000000013c2e76b 6. /build/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*) @ 0x0000000013023182 7. /build/src/Functions/FunctionsConversion.h:2467: 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&&) @ 0x0000000012fa1be4 8. /build/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 @ 0x0000000012fb84ee 9. /build/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 @ 0x0000000012fb7d1a 10. /build/src/Functions/IFunction.h:437: DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000a069f2a 11. /build/src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000012d9965a 12. /build/src/Functions/IFunction.cpp:351: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d93b02 13. /build/src/Functions/IFunction.cpp:177: DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d93698 14. /build/src/Functions/IFunction.cpp:343: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d93aad 15. /build/src/Functions/IFunction.cpp:420: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d95059 16. /build/src/Functions/IFunction.cpp:498: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d95c72 17. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3567: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000014034494 18. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3838: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000014019a9e 19. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3980: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000014018e31 20. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:4304: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000014042fa7 21. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5605: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000014013749 22. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000140127f9 23. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000014011fce 24. /build/src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000001406ce8a 25. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000014973b42 26. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000001497268d 27. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000014974d24 28. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001492924b 29. /build/src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88641 30. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 31. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 2025.07.28 11:51:09.253862 [ 11826 ] {} 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. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000000a074fcb 4. /build/src/Core/DecimalFunctions.h:354: void DB::DecimalUtils::convertToImpl>, void>(DB::Decimal> const&, unsigned int, int&) @ 0x0000000013c285eb 5. /build/src/DataTypes/DataTypesDecimal.cpp:217: T0::FieldType DB::convertFromDecimal>>, DB::DataTypeNumber>(T::FieldType const&, unsigned int) @ 0x0000000013c2e76b 6. /build/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*) @ 0x0000000013023182 7. /build/src/Functions/FunctionsConversion.h:2467: 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&&) @ 0x0000000012fa1be4 8. /build/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 @ 0x0000000012fb84ee 9. /build/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 @ 0x0000000012fb7d1a 10. /build/src/Functions/IFunction.h:437: DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000a069f2a 11. /build/src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000012d9965a 12. /build/src/Functions/IFunction.cpp:351: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d93b02 13. /build/src/Functions/IFunction.cpp:177: DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d93698 14. /build/src/Functions/IFunction.cpp:343: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d93aad 15. /build/src/Functions/IFunction.cpp:420: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d95059 16. /build/src/Functions/IFunction.cpp:498: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d95c72 17. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3567: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000014034494 18. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3838: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000014019a9e 19. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3980: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000014018e31 20. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:4304: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000014042fa7 21. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5605: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000014013749 22. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000140127f9 23. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000014011fce 24. /build/src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000001406ce8a 25. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000014973b42 26. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000001497268d 27. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000014974d24 28. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001492924b 29. /build/src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88641 30. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 31. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 2025.07.28 11:51:09.422933 [ 5327 ] {c050ed42-2f83-47fe-acef-7be6c81c737d} executeQuery: Code: 999. DB::Exception: Fault injection before operation. (KEEPER_EXCEPTION) (version 25.3.6.10636.altinitytest (altinity build)) (from [::1]:50632) (comment: 02456_keeper_retries_during_insert.sql) (query 11, line 16) (in query: INSERT INTO keeper_retries_r1 SETTINGS insert_keeper_fault_injection_probability=1, insert_keeper_retry_max_backoff_ms=1 VALUES ), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: Coordination::Exception::Exception(T&&, Coordination::Error) @ 0x000000001719535e 3. /build/src/Common/ZooKeeper/KeeperException.h:58: Coordination::Exception Coordination::Exception::fromMessage(Coordination::Error, T&&) @ 0x0000000017193090 4. /build/src/Common/ZooKeeper/ZooKeeperWithFaultInjection.cpp:107: DB::ZooKeeperWithFaultInjection::injectFailureBeforeOperationThrow(char const*, String const&) @ 0x000000001718d587 5. /build/src/Common/ZooKeeper/ZooKeeperWithFaultInjection.cpp:134: DB::ZooKeeperWithFaultInjection::getChildren(String const&, Coordination::Stat*, std::shared_ptr const&, Coordination::ListRequestType) @ 0x000000001718e22c 6. /build/src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:226: DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()::operator()() const @ 0x000000001660b90f 7. /build/src/Common/ZooKeeper/ZooKeeperRetries.h:78: void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&, void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&, void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&)::'lambda'()&&) @ 0x000000001660b538 8. /build/src/Common/ZooKeeper/ZooKeeperRetries.h:52: DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&) @ 0x00000000165fcf49 9. /build/src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:316: DB::ReplicatedMergeTreeSinkImpl::consume(DB::Chunk&) @ 0x00000000165fae3a 10. /build/src/Processors/Sinks/SinkToStorage.cpp:10: DB::SinkToStorage::onConsume(DB::Chunk) @ 0x0000000016cee093 11. /build/src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: void std::__function::__policy_invoker::__call_impl[abi:se190107]>(std::__function::__policy_storage const*) @ 0x0000000016c0ad89 12. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000016c0abf5 13. /build/src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: DB::ExceptionKeepingTransform::work() @ 0x0000000016c0a6fe 14. /build/src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x00000000169bd00f 15. /build/src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x00000000169b2105 16. /build/src/Processors/Executors/PipelineExecutor.cpp:170: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x00000000169b16a7 17. /build/src/Processors/Executors/PushingPipelineExecutor.cpp:131: DB::PushingPipelineExecutor::finish() @ 0x00000000169c359f 18. /build/src/Server/TCPHandler.cpp:1128: DB::TCPHandler::processInsertQuery(DB::QueryState&) @ 0x00000000168f0d2c 19. /build/src/Server/TCPHandler.cpp:673: DB::TCPHandler::runImpl() @ 0x00000000168e68bc 20. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 21. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 22. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 23. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 24. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 25. ? @ 0x00007fbc6213eac3 26. ? @ 0x00007fbc621d0850 2025.07.28 11:51:09.431134 [ 5327 ] {} TCPHandler: Code: 999. Coordination::Exception: Fault injection before operation. (KEEPER_EXCEPTION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: Coordination::Exception::Exception(T&&, Coordination::Error) @ 0x000000001719535e 3. /build/src/Common/ZooKeeper/KeeperException.h:58: Coordination::Exception Coordination::Exception::fromMessage(Coordination::Error, T&&) @ 0x0000000017193090 4. /build/src/Common/ZooKeeper/ZooKeeperWithFaultInjection.cpp:107: DB::ZooKeeperWithFaultInjection::injectFailureBeforeOperationThrow(char const*, String const&) @ 0x000000001718d587 5. /build/src/Common/ZooKeeper/ZooKeeperWithFaultInjection.cpp:134: DB::ZooKeeperWithFaultInjection::getChildren(String const&, Coordination::Stat*, std::shared_ptr const&, Coordination::ListRequestType) @ 0x000000001718e22c 6. /build/src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:226: DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()::operator()() const @ 0x000000001660b90f 7. /build/src/Common/ZooKeeper/ZooKeeperRetries.h:78: void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&, void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&, void DB::ZooKeeperRetriesControl::retryLoop::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&)::'lambda'()&&)::'lambda'()&&) @ 0x000000001660b538 8. /build/src/Common/ZooKeeper/ZooKeeperRetries.h:52: DB::ReplicatedMergeTreeSinkImpl::checkQuorumPrecondition(std::shared_ptr const&) @ 0x00000000165fcf49 9. /build/src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:316: DB::ReplicatedMergeTreeSinkImpl::consume(DB::Chunk&) @ 0x00000000165fae3a 10. /build/src/Processors/Sinks/SinkToStorage.cpp:10: DB::SinkToStorage::onConsume(DB::Chunk) @ 0x0000000016cee093 11. /build/src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: void std::__function::__policy_invoker::__call_impl[abi:se190107]>(std::__function::__policy_storage const*) @ 0x0000000016c0ad89 12. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000016c0abf5 13. /build/src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: DB::ExceptionKeepingTransform::work() @ 0x0000000016c0a6fe 14. /build/src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x00000000169bd00f 15. /build/src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x00000000169b2105 16. /build/src/Processors/Executors/PipelineExecutor.cpp:170: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x00000000169b16a7 17. /build/src/Processors/Executors/PushingPipelineExecutor.cpp:131: DB::PushingPipelineExecutor::finish() @ 0x00000000169c359f 18. /build/src/Server/TCPHandler.cpp:1128: DB::TCPHandler::processInsertQuery(DB::QueryState&) @ 0x00000000168f0d2c 19. /build/src/Server/TCPHandler.cpp:673: DB::TCPHandler::runImpl() @ 0x00000000168e68bc 20. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 21. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 22. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 23. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 24. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 25. ? @ 0x00007fbc6213eac3 26. ? @ 0x00007fbc621d0850 2025.07.28 11:51:09.615911 [ 11826 ] {1cdcedd4-8f50-4fd0-81ce-8fc898e3c984} executeQuery: Code: 407. DB::Exception: Convert overflow: In scope SELECT toDecimal64('2147483649', 2) AS x, toInt32(x), toInt32(-x). (DECIMAL_OVERFLOW) (version 25.3.6.10636.altinitytest (altinity build)) (from [::1]:50820) (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. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000000a074fcb 4. /build/src/Core/DecimalFunctions.h:354: void DB::DecimalUtils::convertToImpl, void>(DB::Decimal const&, unsigned int, int&) @ 0x0000000013c28443 5. /build/src/DataTypes/DataTypesDecimal.cpp:217: T0::FieldType DB::convertFromDecimal>, DB::DataTypeNumber>(T::FieldType const&, unsigned int) @ 0x0000000013c2e74b 6. /build/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*) @ 0x0000000013022d62 7. /build/src/Functions/FunctionsConversion.h:2467: 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&&) @ 0x0000000012fa2004 8. /build/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 @ 0x0000000012fb84ee 9. /build/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 @ 0x0000000012fb7d1a 10. /build/src/Functions/IFunction.h:437: DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000a069f2a 11. /build/src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000012d9965a 12. /build/src/Functions/IFunction.cpp:351: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d93b02 13. /build/src/Functions/IFunction.cpp:177: DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d93698 14. /build/src/Functions/IFunction.cpp:343: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d93aad 15. /build/src/Functions/IFunction.cpp:420: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d95059 16. /build/src/Functions/IFunction.cpp:498: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d95c72 17. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3567: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000014034494 18. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3838: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000014019a9e 19. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3980: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000014018e31 20. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:4304: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000014042fa7 21. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5605: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000014013749 22. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000140127f9 23. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000014011fce 24. /build/src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000001406ce8a 25. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000014973b42 26. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000001497268d 27. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000014974d24 28. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001492924b 29. /build/src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88641 30. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 31. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 2025.07.28 11:51:09.622318 [ 11826 ] {} 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. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000000a074fcb 4. /build/src/Core/DecimalFunctions.h:354: void DB::DecimalUtils::convertToImpl, void>(DB::Decimal const&, unsigned int, int&) @ 0x0000000013c28443 5. /build/src/DataTypes/DataTypesDecimal.cpp:217: T0::FieldType DB::convertFromDecimal>, DB::DataTypeNumber>(T::FieldType const&, unsigned int) @ 0x0000000013c2e74b 6. /build/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*) @ 0x0000000013022d62 7. /build/src/Functions/FunctionsConversion.h:2467: 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&&) @ 0x0000000012fa2004 8. /build/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 @ 0x0000000012fb84ee 9. /build/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 @ 0x0000000012fb7d1a 10. /build/src/Functions/IFunction.h:437: DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000a069f2a 11. /build/src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000012d9965a 12. /build/src/Functions/IFunction.cpp:351: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d93b02 13. /build/src/Functions/IFunction.cpp:177: DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d93698 14. /build/src/Functions/IFunction.cpp:343: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d93aad 15. /build/src/Functions/IFunction.cpp:420: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d95059 16. /build/src/Functions/IFunction.cpp:498: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d95c72 17. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3567: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000014034494 18. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3838: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000014019a9e 19. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3980: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000014018e31 20. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:4304: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000014042fa7 21. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5605: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000014013749 22. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000140127f9 23. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000014011fce 24. /build/src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000001406ce8a 25. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000014973b42 26. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000001497268d 27. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000014974d24 28. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001492924b 29. /build/src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88641 30. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 31. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 2025.07.28 11:51:09.711412 [ 7625 ] {3a59df97-8140-4653-ba08-ae552a5f6aa3} executeQuery: Code: 48. DB::Exception: CHECK PART/PARTITION are not supported for TinyLog. (NOT_IMPLEMENTED) (version 25.3.6.10636.altinitytest (altinity build)) (from [::1]:50906) (comment: 00063_check_query.sql) (query 6, line 11) (in query: CHECK TABLE check_query_tiny_log PARTITION tuple();), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x000000000a06b56b 4. /build/src/Storages/StorageLog.cpp:937: DB::StorageLog::getCheckTaskList(std::variant, String> const&, std::shared_ptr) @ 0x000000001605e949 5. /build/src/Interpreters/InterpreterCheckQuery.cpp:110: DB::InterpreterCheckQuery::execute() @ 0x0000000014ce3151 6. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88dc9 7. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 8. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 9. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 10. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 11. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 12. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 13. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 14. ? @ 0x00007fbc6213eac3 15. ? @ 0x00007fbc621d0850 2025.07.28 11:51:09.717958 [ 7625 ] {} TCPHandler: Code: 48. DB::Exception: CHECK PART/PARTITION are not supported for TinyLog. (NOT_IMPLEMENTED), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x000000000a06b56b 4. /build/src/Storages/StorageLog.cpp:937: DB::StorageLog::getCheckTaskList(std::variant, String> const&, std::shared_ptr) @ 0x000000001605e949 5. /build/src/Interpreters/InterpreterCheckQuery.cpp:110: DB::InterpreterCheckQuery::execute() @ 0x0000000014ce3151 6. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88dc9 7. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 8. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 9. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 10. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 11. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 12. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 13. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 14. ? @ 0x00007fbc6213eac3 15. ? @ 0x00007fbc621d0850 2025.07.28 11:51:09.768687 [ 7625 ] {4548510d-2be6-47e2-b8f9-5a7f5514710e} executeQuery: Code: 48. DB::Exception: CHECK PART/PARTITION are not supported for TinyLog. (NOT_IMPLEMENTED) (version 25.3.6.10636.altinitytest (altinity build)) (from [::1]:50906) (comment: 00063_check_query.sql) (query 7, line 12) (in query: CHECK TABLE check_query_tiny_log PART 'all_0_0_0';), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x000000000a06b56b 4. /build/src/Storages/StorageLog.cpp:937: DB::StorageLog::getCheckTaskList(std::variant, String> const&, std::shared_ptr) @ 0x000000001605e949 5. /build/src/Interpreters/InterpreterCheckQuery.cpp:110: DB::InterpreterCheckQuery::execute() @ 0x0000000014ce3151 6. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88dc9 7. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 8. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 9. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 10. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 11. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 12. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 13. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 14. ? @ 0x00007fbc6213eac3 15. ? @ 0x00007fbc621d0850 2025.07.28 11:51:09.776511 [ 7625 ] {} TCPHandler: Code: 48. DB::Exception: CHECK PART/PARTITION are not supported for TinyLog. (NOT_IMPLEMENTED), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x000000000a06b56b 4. /build/src/Storages/StorageLog.cpp:937: DB::StorageLog::getCheckTaskList(std::variant, String> const&, std::shared_ptr) @ 0x000000001605e949 5. /build/src/Interpreters/InterpreterCheckQuery.cpp:110: DB::InterpreterCheckQuery::execute() @ 0x0000000014ce3151 6. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88dc9 7. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 8. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 9. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 10. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 11. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 12. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 13. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 14. ? @ 0x00007fbc6213eac3 15. ? @ 0x00007fbc621d0850 2025.07.28 11:51:11.805968 [ 11826 ] {68a452ae-5005-40a7-9629-cf240c1a6b40} executeQuery: Code: 407. DB::Exception: Convert overflow: In scope SELECT toDecimal128('-1', 7) AS x, toUInt64(x). (DECIMAL_OVERFLOW) (version 25.3.6.10636.altinitytest (altinity build)) (from [::1]:50820) (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. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000000a074fcb 4. /build/src/Core/DecimalFunctions.h:354: void DB::DecimalUtils::convertToImpl>, void>(DB::Decimal> const&, unsigned int, unsigned long&) @ 0x0000000013c2bd4c 5. /build/src/DataTypes/DataTypesDecimal.cpp:217: T0::FieldType DB::convertFromDecimal>>, DB::DataTypeNumber>(T::FieldType const&, unsigned int) @ 0x0000000013c2ede9 6. /build/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*) @ 0x0000000012ff4cc2 7. /build/src/Functions/FunctionsConversion.h:2467: 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&&) @ 0x0000000012f9d7c4 8. /build/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 @ 0x0000000012fb254e 9. /build/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 @ 0x0000000012fb1d7a 10. /build/src/Functions/IFunction.h:437: DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000a069f2a 11. /build/src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000012d9965a 12. /build/src/Functions/IFunction.cpp:351: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d93b02 13. /build/src/Functions/IFunction.cpp:177: DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d93698 14. /build/src/Functions/IFunction.cpp:343: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d93aad 15. /build/src/Functions/IFunction.cpp:420: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d95059 16. /build/src/Functions/IFunction.cpp:498: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d95c72 17. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3567: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000014034494 18. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3838: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000014019a9e 19. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3980: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000014018e31 20. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:4304: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000014042fa7 21. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5605: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000014013749 22. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000140127f9 23. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000014011fce 24. /build/src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000001406ce8a 25. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000014973b42 26. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000001497268d 27. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000014974d24 28. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001492924b 29. /build/src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88641 30. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 31. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 2025.07.28 11:51:11.850877 [ 11826 ] {} 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. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000000a074fcb 4. /build/src/Core/DecimalFunctions.h:354: void DB::DecimalUtils::convertToImpl>, void>(DB::Decimal> const&, unsigned int, unsigned long&) @ 0x0000000013c2bd4c 5. /build/src/DataTypes/DataTypesDecimal.cpp:217: T0::FieldType DB::convertFromDecimal>>, DB::DataTypeNumber>(T::FieldType const&, unsigned int) @ 0x0000000013c2ede9 6. /build/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*) @ 0x0000000012ff4cc2 7. /build/src/Functions/FunctionsConversion.h:2467: 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&&) @ 0x0000000012f9d7c4 8. /build/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 @ 0x0000000012fb254e 9. /build/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 @ 0x0000000012fb1d7a 10. /build/src/Functions/IFunction.h:437: DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000a069f2a 11. /build/src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000012d9965a 12. /build/src/Functions/IFunction.cpp:351: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d93b02 13. /build/src/Functions/IFunction.cpp:177: DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d93698 14. /build/src/Functions/IFunction.cpp:343: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d93aad 15. /build/src/Functions/IFunction.cpp:420: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d95059 16. /build/src/Functions/IFunction.cpp:498: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d95c72 17. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3567: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000014034494 18. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3838: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000014019a9e 19. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3980: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000014018e31 20. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:4304: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000014042fa7 21. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5605: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000014013749 22. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000140127f9 23. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000014011fce 24. /build/src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000001406ce8a 25. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000014973b42 26. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000001497268d 27. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000014974d24 28. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001492924b 29. /build/src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88641 30. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 31. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 2025.07.28 11:51:12.111140 [ 11826 ] {baf8c8d7-ec46-43a4-9040-c274c7f2149b} executeQuery: Code: 407. DB::Exception: Convert overflow: In scope SELECT toDecimal128('-1', 7) AS x, toUInt32(x). (DECIMAL_OVERFLOW) (version 25.3.6.10636.altinitytest (altinity build)) (from [::1]:50820) (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. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000000a074fcb 4. /build/src/Core/DecimalFunctions.h:354: void DB::DecimalUtils::convertToImpl>, void>(DB::Decimal> const&, unsigned int, unsigned int&) @ 0x0000000013c28e4b 5. /build/src/DataTypes/DataTypesDecimal.cpp:217: T0::FieldType DB::convertFromDecimal>>, DB::DataTypeNumber>(T::FieldType const&, unsigned int) @ 0x0000000013c2ea2b 6. /build/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*) @ 0x0000000012feb642 7. /build/src/Functions/FunctionsConversion.h:2467: 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&&) @ 0x0000000012f9ca24 8. /build/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 @ 0x0000000012fb122e 9. /build/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 @ 0x0000000012fb0a5a 10. /build/src/Functions/IFunction.h:437: DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000a069f2a 11. /build/src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000012d9965a 12. /build/src/Functions/IFunction.cpp:351: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d93b02 13. /build/src/Functions/IFunction.cpp:177: DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d93698 14. /build/src/Functions/IFunction.cpp:343: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d93aad 15. /build/src/Functions/IFunction.cpp:420: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d95059 16. /build/src/Functions/IFunction.cpp:498: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d95c72 17. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3567: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000014034494 18. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3838: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000014019a9e 19. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3980: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000014018e31 20. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:4304: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000014042fa7 21. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5605: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000014013749 22. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000140127f9 23. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000014011fce 24. /build/src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000001406ce8a 25. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000014973b42 26. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000001497268d 27. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000014974d24 28. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001492924b 29. /build/src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88641 30. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 31. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 2025.07.28 11:51:12.116353 [ 11826 ] {} 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. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000000a074fcb 4. /build/src/Core/DecimalFunctions.h:354: void DB::DecimalUtils::convertToImpl>, void>(DB::Decimal> const&, unsigned int, unsigned int&) @ 0x0000000013c28e4b 5. /build/src/DataTypes/DataTypesDecimal.cpp:217: T0::FieldType DB::convertFromDecimal>>, DB::DataTypeNumber>(T::FieldType const&, unsigned int) @ 0x0000000013c2ea2b 6. /build/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*) @ 0x0000000012feb642 7. /build/src/Functions/FunctionsConversion.h:2467: 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&&) @ 0x0000000012f9ca24 8. /build/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 @ 0x0000000012fb122e 9. /build/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 @ 0x0000000012fb0a5a 10. /build/src/Functions/IFunction.h:437: DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000a069f2a 11. /build/src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000012d9965a 12. /build/src/Functions/IFunction.cpp:351: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d93b02 13. /build/src/Functions/IFunction.cpp:177: DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d93698 14. /build/src/Functions/IFunction.cpp:343: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d93aad 15. /build/src/Functions/IFunction.cpp:420: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d95059 16. /build/src/Functions/IFunction.cpp:498: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d95c72 17. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3567: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000014034494 18. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3838: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000014019a9e 19. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3980: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000014018e31 20. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:4304: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000014042fa7 21. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5605: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000014013749 22. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000140127f9 23. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000014011fce 24. /build/src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000001406ce8a 25. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000014973b42 26. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000001497268d 27. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000014974d24 28. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001492924b 29. /build/src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88641 30. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 31. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 2025.07.28 11:51:12.420306 [ 11826 ] {eb3f0085-a86a-46df-9099-a130ebcb2e5a} executeQuery: Code: 407. DB::Exception: Convert overflow: In scope SELECT toDecimal128('-1', 7) AS x, toUInt16(x). (DECIMAL_OVERFLOW) (version 25.3.6.10636.altinitytest (altinity build)) (from [::1]:50820) (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. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000000a074fcb 4. /build/src/Core/DecimalFunctions.h:354: void DB::DecimalUtils::convertToImpl>, void>(DB::Decimal> const&, unsigned int, unsigned short&) @ 0x0000000013c27bec 5. /build/src/DataTypes/DataTypesDecimal.cpp:217: T0::FieldType DB::convertFromDecimal>>, DB::DataTypeNumber>(T::FieldType const&, unsigned int) @ 0x0000000013c2e6ab 6. /build/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*) @ 0x0000000012fe2022 7. /build/src/Functions/FunctionsConversion.h:2467: 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&&) @ 0x0000000012f9bc84 8. /build/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 @ 0x0000000012faff0e 9. /build/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 @ 0x0000000012faf73a 10. /build/src/Functions/IFunction.h:437: DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000a069f2a 11. /build/src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000012d9965a 12. /build/src/Functions/IFunction.cpp:351: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d93b02 13. /build/src/Functions/IFunction.cpp:177: DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d93698 14. /build/src/Functions/IFunction.cpp:343: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d93aad 15. /build/src/Functions/IFunction.cpp:420: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d95059 16. /build/src/Functions/IFunction.cpp:498: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d95c72 17. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3567: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000014034494 18. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3838: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000014019a9e 19. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3980: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000014018e31 20. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:4304: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000014042fa7 21. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5605: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000014013749 22. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000140127f9 23. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000014011fce 24. /build/src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000001406ce8a 25. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000014973b42 26. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000001497268d 27. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000014974d24 28. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001492924b 29. /build/src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88641 30. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 31. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 2025.07.28 11:51:12.423175 [ 11826 ] {} 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. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000000a074fcb 4. /build/src/Core/DecimalFunctions.h:354: void DB::DecimalUtils::convertToImpl>, void>(DB::Decimal> const&, unsigned int, unsigned short&) @ 0x0000000013c27bec 5. /build/src/DataTypes/DataTypesDecimal.cpp:217: T0::FieldType DB::convertFromDecimal>>, DB::DataTypeNumber>(T::FieldType const&, unsigned int) @ 0x0000000013c2e6ab 6. /build/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*) @ 0x0000000012fe2022 7. /build/src/Functions/FunctionsConversion.h:2467: 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&&) @ 0x0000000012f9bc84 8. /build/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 @ 0x0000000012faff0e 9. /build/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 @ 0x0000000012faf73a 10. /build/src/Functions/IFunction.h:437: DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000a069f2a 11. /build/src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000012d9965a 12. /build/src/Functions/IFunction.cpp:351: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d93b02 13. /build/src/Functions/IFunction.cpp:177: DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d93698 14. /build/src/Functions/IFunction.cpp:343: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d93aad 15. /build/src/Functions/IFunction.cpp:420: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d95059 16. /build/src/Functions/IFunction.cpp:498: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d95c72 17. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3567: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000014034494 18. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3838: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000014019a9e 19. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3980: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000014018e31 20. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:4304: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000014042fa7 21. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5605: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000014013749 22. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000140127f9 23. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000014011fce 24. /build/src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000001406ce8a 25. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000014973b42 26. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000001497268d 27. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000014974d24 28. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001492924b 29. /build/src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88641 30. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 31. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 2025.07.28 11:51:12.612683 [ 11826 ] {7f8ac8de-3fd0-40fb-b041-14b609e683e5} executeQuery: Code: 407. DB::Exception: Convert overflow: In scope SELECT toDecimal128('-1', 7) AS x, toUInt8(x). (DECIMAL_OVERFLOW) (version 25.3.6.10636.altinitytest (altinity build)) (from [::1]:50820) (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. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000000a074fcb 4. /build/src/Core/DecimalFunctions.h:354: void DB::DecimalUtils::convertToImpl>, void>(DB::Decimal> const&, unsigned int, char8_t&) @ 0x0000000013c2a16b 5. /build/src/DataTypes/DataTypesDecimal.cpp:217: T0::FieldType DB::convertFromDecimal>>, DB::DataTypeNumber>(T::FieldType const&, unsigned int) @ 0x0000000013c2e34b 6. /build/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*) @ 0x0000000012fd83be 7. /build/src/Functions/FunctionsConversion.h:2467: 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&&) @ 0x0000000012f9aeb2 8. /build/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 @ 0x0000000012faebee 9. /build/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 @ 0x0000000012fae41a 10. /build/src/Functions/IFunction.h:437: DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000a069f2a 11. /build/src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000012d9965a 12. /build/src/Functions/IFunction.cpp:351: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d93b02 13. /build/src/Functions/IFunction.cpp:177: DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d93698 14. /build/src/Functions/IFunction.cpp:343: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d93aad 15. /build/src/Functions/IFunction.cpp:420: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d95059 16. /build/src/Functions/IFunction.cpp:498: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d95c72 17. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3567: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000014034494 18. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3838: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000014019a9e 19. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3980: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000014018e31 20. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:4304: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000014042fa7 21. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5605: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000014013749 22. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000140127f9 23. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000014011fce 24. /build/src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000001406ce8a 25. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000014973b42 26. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000001497268d 27. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000014974d24 28. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001492924b 29. /build/src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88641 30. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 31. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 2025.07.28 11:51:12.627548 [ 3285 ] {47c6be51-5707-4768-a8a4-c3c8cee4d0b8} executeQuery: Code: 62. DB::Exception: Cannot TRUNCATE dictionary. (SYNTAX_ERROR) (version 25.3.6.10636.altinitytest (altinity build)) (from [::1]:37406) (comment: 02162_range_hashed_dictionary_ddl_expression.sql) (query 7, line 28) (in query: DROP DICTIONARY 02162_test_dictionary;), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000000a074fcb 4. /build/src/Interpreters/InterpreterDropQuery.cpp:266: DB::InterpreterDropQuery::executeToTableImpl(std::shared_ptr const&, DB::ASTDropQuery&, std::shared_ptr&, StrongTypedef, DB::UUIDTag>&) @ 0x0000000014915b7b 5. /build/src/Interpreters/InterpreterDropQuery.cpp:118: DB::InterpreterDropQuery::executeToTable(DB::ASTDropQuery&) @ 0x00000000149137b4 6. /build/src/Interpreters/InterpreterDropQuery.cpp:91: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000014912f07 7. /build/src/Interpreters/InterpreterDropQuery.cpp:72: DB::InterpreterDropQuery::execute() @ 0x0000000014912b65 8. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88dc9 9. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 10. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 11. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 12. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 13. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 14. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 15. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 16. ? @ 0x00007fbc6213eac3 17. ? @ 0x00007fbc621d0850 2025.07.28 11:51:12.660535 [ 11826 ] {} 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. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000000a074fcb 4. /build/src/Core/DecimalFunctions.h:354: void DB::DecimalUtils::convertToImpl>, void>(DB::Decimal> const&, unsigned int, char8_t&) @ 0x0000000013c2a16b 5. /build/src/DataTypes/DataTypesDecimal.cpp:217: T0::FieldType DB::convertFromDecimal>>, DB::DataTypeNumber>(T::FieldType const&, unsigned int) @ 0x0000000013c2e34b 6. /build/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*) @ 0x0000000012fd83be 7. /build/src/Functions/FunctionsConversion.h:2467: 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&&) @ 0x0000000012f9aeb2 8. /build/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 @ 0x0000000012faebee 9. /build/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 @ 0x0000000012fae41a 10. /build/src/Functions/IFunction.h:437: DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000a069f2a 11. /build/src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000012d9965a 12. /build/src/Functions/IFunction.cpp:351: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d93b02 13. /build/src/Functions/IFunction.cpp:177: DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d93698 14. /build/src/Functions/IFunction.cpp:343: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d93aad 15. /build/src/Functions/IFunction.cpp:420: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d95059 16. /build/src/Functions/IFunction.cpp:498: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d95c72 17. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3567: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000014034494 18. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3838: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000014019a9e 19. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3980: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000014018e31 20. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:4304: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000014042fa7 21. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5605: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000014013749 22. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000140127f9 23. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000014011fce 24. /build/src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000001406ce8a 25. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000014973b42 26. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000001497268d 27. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000014974d24 28. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001492924b 29. /build/src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88641 30. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 31. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 2025.07.28 11:51:12.667643 [ 3285 ] {} TCPHandler: Code: 62. DB::Exception: Cannot TRUNCATE dictionary. (SYNTAX_ERROR), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000000a074fcb 4. /build/src/Interpreters/InterpreterDropQuery.cpp:266: DB::InterpreterDropQuery::executeToTableImpl(std::shared_ptr const&, DB::ASTDropQuery&, std::shared_ptr&, StrongTypedef, DB::UUIDTag>&) @ 0x0000000014915b7b 5. /build/src/Interpreters/InterpreterDropQuery.cpp:118: DB::InterpreterDropQuery::executeToTable(DB::ASTDropQuery&) @ 0x00000000149137b4 6. /build/src/Interpreters/InterpreterDropQuery.cpp:91: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000014912f07 7. /build/src/Interpreters/InterpreterDropQuery.cpp:72: DB::InterpreterDropQuery::execute() @ 0x0000000014912b65 8. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88dc9 9. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 10. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 11. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 12. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 13. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 14. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 15. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 16. ? @ 0x00007fbc6213eac3 17. ? @ 0x00007fbc621d0850 2025.07.28 11:51:12.871791 [ 7630 ] {8299fa45-17d3-4fa8-9591-a68a84887660} executeQuery: Code: 62. DB::Exception: Cannot TRUNCATE dictionary. (SYNTAX_ERROR) (version 25.3.6.10636.altinitytest (altinity build)) (from [::1]:37110) (comment: 02162_range_hashed_dictionary_ddl_expression.sql) (in query: DROP DATABASE IF EXISTS test_k161n8ps SYNC ), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000000a074fcb 4. /build/src/Interpreters/InterpreterDropQuery.cpp:266: DB::InterpreterDropQuery::executeToTableImpl(std::shared_ptr const&, DB::ASTDropQuery&, std::shared_ptr&, StrongTypedef, DB::UUIDTag>&) @ 0x0000000014915b7b 5. /build/src/Interpreters/InterpreterDropQuery.cpp:461: DB::InterpreterDropQuery::executeToDatabaseImpl(DB::ASTDropQuery const&, std::shared_ptr&, std::vector, DB::UUIDTag>, std::allocator, DB::UUIDTag>>>&) @ 0x0000000014917707 6. /build/src/Interpreters/InterpreterDropQuery.cpp:363: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x0000000014913988 7. /build/src/Interpreters/InterpreterDropQuery.cpp:99: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000014913142 8. /build/src/Interpreters/InterpreterDropQuery.cpp:72: DB::InterpreterDropQuery::execute() @ 0x0000000014912b65 9. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88dc9 10. /build/src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x0000000014c8ca7b 11. /build/src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000001686da12 12. /build/src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x0000000016870807 13. /build/src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x0000000016907e99 14. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 15. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 16. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 17. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 18. ? @ 0x00007fbc6213eac3 19. ? @ 0x00007fbc621d0850 2025.07.28 11:51:12.875765 [ 7630 ] {8299fa45-17d3-4fa8-9591-a68a84887660} DynamicQueryHandler: Code: 62. DB::Exception: Cannot TRUNCATE dictionary. (SYNTAX_ERROR), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000000a074fcb 4. /build/src/Interpreters/InterpreterDropQuery.cpp:266: DB::InterpreterDropQuery::executeToTableImpl(std::shared_ptr const&, DB::ASTDropQuery&, std::shared_ptr&, StrongTypedef, DB::UUIDTag>&) @ 0x0000000014915b7b 5. /build/src/Interpreters/InterpreterDropQuery.cpp:461: DB::InterpreterDropQuery::executeToDatabaseImpl(DB::ASTDropQuery const&, std::shared_ptr&, std::vector, DB::UUIDTag>, std::allocator, DB::UUIDTag>>>&) @ 0x0000000014917707 6. /build/src/Interpreters/InterpreterDropQuery.cpp:363: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x0000000014913988 7. /build/src/Interpreters/InterpreterDropQuery.cpp:99: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000014913142 8. /build/src/Interpreters/InterpreterDropQuery.cpp:72: DB::InterpreterDropQuery::execute() @ 0x0000000014912b65 9. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88dc9 10. /build/src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x0000000014c8ca7b 11. /build/src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000001686da12 12. /build/src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x0000000016870807 13. /build/src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x0000000016907e99 14. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 15. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 16. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 17. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 18. ? @ 0x00007fbc6213eac3 19. ? @ 0x00007fbc621d0850 (version 25.3.6.10636.altinitytest (altinity build)) 2025.07.28 11:51:12.900010 [ 11826 ] {625b9d89-f9d9-43e9-a93d-b31e523b7ce0} executeQuery: Code: 407. DB::Exception: Convert overflow: In scope SELECT toDecimal64('-1', 5) AS x, toUInt64(x). (DECIMAL_OVERFLOW) (version 25.3.6.10636.altinitytest (altinity build)) (from [::1]:50820) (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. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000000a074fcb 4. /build/src/Core/DecimalFunctions.h:334: T0::FieldType DB::convertFromDecimal>, DB::DataTypeNumber>(T::FieldType const&, unsigned int) @ 0x0000000013c2ed99 5. /build/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*) @ 0x0000000012ff48be 6. /build/src/Functions/FunctionsConversion.h:2467: 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&&) @ 0x0000000012f9dbe4 7. /build/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 @ 0x0000000012fb254e 8. /build/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 @ 0x0000000012fb1d7a 9. /build/src/Functions/IFunction.h:437: DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000a069f2a 10. /build/src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000012d9965a 11. /build/src/Functions/IFunction.cpp:351: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d93b02 12. /build/src/Functions/IFunction.cpp:177: DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d93698 13. /build/src/Functions/IFunction.cpp:343: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d93aad 14. /build/src/Functions/IFunction.cpp:420: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d95059 15. /build/src/Functions/IFunction.cpp:498: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d95c72 16. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3567: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000014034494 17. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3838: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000014019a9e 18. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3980: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000014018e31 19. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:4304: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000014042fa7 20. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5605: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000014013749 21. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000140127f9 22. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000014011fce 23. /build/src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000001406ce8a 24. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000014973b42 25. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000001497268d 26. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000014974d24 27. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001492924b 28. /build/src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88641 29. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 30. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 31. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 2025.07.28 11:51:12.908788 [ 11826 ] {} 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. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000000a074fcb 4. /build/src/Core/DecimalFunctions.h:334: T0::FieldType DB::convertFromDecimal>, DB::DataTypeNumber>(T::FieldType const&, unsigned int) @ 0x0000000013c2ed99 5. /build/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*) @ 0x0000000012ff48be 6. /build/src/Functions/FunctionsConversion.h:2467: 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&&) @ 0x0000000012f9dbe4 7. /build/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 @ 0x0000000012fb254e 8. /build/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 @ 0x0000000012fb1d7a 9. /build/src/Functions/IFunction.h:437: DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000a069f2a 10. /build/src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000012d9965a 11. /build/src/Functions/IFunction.cpp:351: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d93b02 12. /build/src/Functions/IFunction.cpp:177: DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d93698 13. /build/src/Functions/IFunction.cpp:343: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d93aad 14. /build/src/Functions/IFunction.cpp:420: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d95059 15. /build/src/Functions/IFunction.cpp:498: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d95c72 16. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3567: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000014034494 17. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3838: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000014019a9e 18. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3980: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000014018e31 19. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:4304: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000014042fa7 20. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5605: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000014013749 21. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000140127f9 22. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000014011fce 23. /build/src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000001406ce8a 24. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000014973b42 25. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000001497268d 26. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000014974d24 27. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001492924b 28. /build/src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88641 29. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 30. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 31. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 2025.07.28 11:51:13.084690 [ 5874 ] {763bfee1-05da-4e3a-bbbf-ae399234981b} InterpreterCheckQuery: Check query for table test_9.tp_1 (6084bb2c-7960-43f7-b13d-0f487ee1618d) 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.6.10636.altinitytest (altinity build)) 2025.07.28 11:51:13.190018 [ 11826 ] {c414b119-ee86-4bcd-b99f-38fe6e1b589b} executeQuery: Code: 407. DB::Exception: Convert overflow: In scope SELECT toDecimal64('-1', 5) AS x, toUInt32(x). (DECIMAL_OVERFLOW) (version 25.3.6.10636.altinitytest (altinity build)) (from [::1]:50820) (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. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000000a074fcb 4. /build/src/Core/DecimalFunctions.h:354: T0::FieldType DB::convertFromDecimal>, DB::DataTypeNumber>(T::FieldType const&, unsigned int) @ 0x0000000013c2e9de 5. /build/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*) @ 0x0000000012feb222 6. /build/src/Functions/FunctionsConversion.h:2467: 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&&) @ 0x0000000012f9ce24 7. /build/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 @ 0x0000000012fb122e 8. /build/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 @ 0x0000000012fb0a5a 9. /build/src/Functions/IFunction.h:437: DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000a069f2a 10. /build/src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000012d9965a 11. /build/src/Functions/IFunction.cpp:351: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d93b02 12. /build/src/Functions/IFunction.cpp:177: DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d93698 13. /build/src/Functions/IFunction.cpp:343: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d93aad 14. /build/src/Functions/IFunction.cpp:420: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d95059 15. /build/src/Functions/IFunction.cpp:498: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d95c72 16. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3567: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000014034494 17. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3838: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000014019a9e 18. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3980: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000014018e31 19. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:4304: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000014042fa7 20. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5605: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000014013749 21. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000140127f9 22. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000014011fce 23. /build/src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000001406ce8a 24. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000014973b42 25. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000001497268d 26. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000014974d24 27. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001492924b 28. /build/src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88641 29. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 30. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 31. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 2025.07.28 11:51:13.191249 [ 4581 ] {4b134afb-8368-4c45-8bf4-38bfab3d58e6} executeQuery: Code: 36. DB::Exception: Argument 'kafka_broker_list' must be a literal, get Function_equals (value: a = '1'). (BAD_ARGUMENTS) (version 25.3.6.10636.altinitytest (altinity build)) (from [::1]:37480) (comment: 03305_fix_kafka_table_with_kw_arguments.sql) (query 1, line 3) (in query: CREATE TABLE default.test ( `id` UInt32, `message` String ) ENGINE = Kafka(a = '1', 'clickhouse');), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, String&&, String&&) @ 0x000000001098ed2b 4. /build/src/Storages/checkAndGetLiteralArgument.cpp:25: String DB::checkAndGetLiteralArgument(std::shared_ptr const&, String const&) @ 0x0000000016051f87 5. /build/src/Storages/Kafka/StorageKafkaUtils.cpp:169: DB::registerStorageKafka(DB::StorageFactory&)::$_0::operator()(DB::StorageFactory::Arguments const&) const @ 0x000000001328b0b1 6. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000015d81ea2 7. /build/src/Interpreters/InterpreterCreateQuery.cpp:1945: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x00000000149009bb 8. /build/src/Interpreters/InterpreterCreateQuery.cpp:1743: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000148f9aa9 9. /build/src/Interpreters/InterpreterCreateQuery.cpp:2352: DB::InterpreterCreateQuery::execute() @ 0x0000000014905a41 10. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88dc9 11. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 12. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 13. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 14. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 15. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 16. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 17. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 18. ? @ 0x00007fbc6213eac3 19. ? @ 0x00007fbc621d0850 2025.07.28 11:51:13.194258 [ 11826 ] {} 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. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000000a074fcb 4. /build/src/Core/DecimalFunctions.h:354: T0::FieldType DB::convertFromDecimal>, DB::DataTypeNumber>(T::FieldType const&, unsigned int) @ 0x0000000013c2e9de 5. /build/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*) @ 0x0000000012feb222 6. /build/src/Functions/FunctionsConversion.h:2467: 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&&) @ 0x0000000012f9ce24 7. /build/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 @ 0x0000000012fb122e 8. /build/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 @ 0x0000000012fb0a5a 9. /build/src/Functions/IFunction.h:437: DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000a069f2a 10. /build/src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000012d9965a 11. /build/src/Functions/IFunction.cpp:351: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d93b02 12. /build/src/Functions/IFunction.cpp:177: DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d93698 13. /build/src/Functions/IFunction.cpp:343: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d93aad 14. /build/src/Functions/IFunction.cpp:420: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d95059 15. /build/src/Functions/IFunction.cpp:498: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d95c72 16. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3567: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000014034494 17. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3838: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000014019a9e 18. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3980: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000014018e31 19. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:4304: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000014042fa7 20. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5605: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000014013749 21. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000140127f9 22. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000014011fce 23. /build/src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000001406ce8a 24. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000014973b42 25. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000001497268d 26. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000014974d24 27. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001492924b 28. /build/src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88641 29. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 30. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 31. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 2025.07.28 11:51:13.199812 [ 4581 ] {} TCPHandler: Code: 36. DB::Exception: Argument 'kafka_broker_list' must be a literal, get Function_equals (value: a = '1'). (BAD_ARGUMENTS), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, String&&, String&&) @ 0x000000001098ed2b 4. /build/src/Storages/checkAndGetLiteralArgument.cpp:25: String DB::checkAndGetLiteralArgument(std::shared_ptr const&, String const&) @ 0x0000000016051f87 5. /build/src/Storages/Kafka/StorageKafkaUtils.cpp:169: DB::registerStorageKafka(DB::StorageFactory&)::$_0::operator()(DB::StorageFactory::Arguments const&) const @ 0x000000001328b0b1 6. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000015d81ea2 7. /build/src/Interpreters/InterpreterCreateQuery.cpp:1945: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x00000000149009bb 8. /build/src/Interpreters/InterpreterCreateQuery.cpp:1743: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000148f9aa9 9. /build/src/Interpreters/InterpreterCreateQuery.cpp:2352: DB::InterpreterCreateQuery::execute() @ 0x0000000014905a41 10. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88dc9 11. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 12. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 13. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 14. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 15. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 16. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 17. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 18. ? @ 0x00007fbc6213eac3 19. ? @ 0x00007fbc621d0850 2025.07.28 11:51:13.596627 [ 11826 ] {12cc123e-0650-4892-8b79-8f58d33856c2} executeQuery: Code: 407. DB::Exception: Convert overflow: In scope SELECT toDecimal64('-1', 5) AS x, toUInt16(x). (DECIMAL_OVERFLOW) (version 25.3.6.10636.altinitytest (altinity build)) (from [::1]:50820) (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. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000000a074fcb 4. /build/src/Core/DecimalFunctions.h:354: T0::FieldType DB::convertFromDecimal>, DB::DataTypeNumber>(T::FieldType const&, unsigned int) @ 0x0000000013c2e664 5. /build/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*) @ 0x0000000012fe1c02 6. /build/src/Functions/FunctionsConversion.h:2467: 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&&) @ 0x0000000012f9c0a4 7. /build/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 @ 0x0000000012faff0e 8. /build/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 @ 0x0000000012faf73a 9. /build/src/Functions/IFunction.h:437: DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000a069f2a 10. /build/src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000012d9965a 11. /build/src/Functions/IFunction.cpp:351: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d93b02 12. /build/src/Functions/IFunction.cpp:177: DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d93698 13. /build/src/Functions/IFunction.cpp:343: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d93aad 14. /build/src/Functions/IFunction.cpp:420: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d95059 15. /build/src/Functions/IFunction.cpp:498: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d95c72 16. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3567: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000014034494 17. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3838: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000014019a9e 18. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3980: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000014018e31 19. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:4304: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000014042fa7 20. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5605: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000014013749 21. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000140127f9 22. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000014011fce 23. /build/src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000001406ce8a 24. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000014973b42 25. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000001497268d 26. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000014974d24 27. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001492924b 28. /build/src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88641 29. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 30. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 31. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 2025.07.28 11:51:13.600857 [ 11826 ] {} 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. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000000a074fcb 4. /build/src/Core/DecimalFunctions.h:354: T0::FieldType DB::convertFromDecimal>, DB::DataTypeNumber>(T::FieldType const&, unsigned int) @ 0x0000000013c2e664 5. /build/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*) @ 0x0000000012fe1c02 6. /build/src/Functions/FunctionsConversion.h:2467: 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&&) @ 0x0000000012f9c0a4 7. /build/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 @ 0x0000000012faff0e 8. /build/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 @ 0x0000000012faf73a 9. /build/src/Functions/IFunction.h:437: DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000a069f2a 10. /build/src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000012d9965a 11. /build/src/Functions/IFunction.cpp:351: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d93b02 12. /build/src/Functions/IFunction.cpp:177: DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d93698 13. /build/src/Functions/IFunction.cpp:343: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d93aad 14. /build/src/Functions/IFunction.cpp:420: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d95059 15. /build/src/Functions/IFunction.cpp:498: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d95c72 16. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3567: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000014034494 17. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3838: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000014019a9e 18. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3980: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000014018e31 19. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:4304: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000014042fa7 20. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5605: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000014013749 21. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000140127f9 22. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000014011fce 23. /build/src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000001406ce8a 24. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000014973b42 25. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000001497268d 26. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000014974d24 27. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001492924b 28. /build/src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88641 29. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 30. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 31. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 2025.07.28 11:51:13.737279 [ 11826 ] {f5b9ad6c-7ef4-4a76-9ea1-abef61d0062e} executeQuery: Code: 407. DB::Exception: Convert overflow: In scope SELECT toDecimal64('-1', 5) AS x, toUInt8(x). (DECIMAL_OVERFLOW) (version 25.3.6.10636.altinitytest (altinity build)) (from [::1]:50820) (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. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000000a074fcb 4. /build/src/Core/DecimalFunctions.h:354: T0::FieldType DB::convertFromDecimal>, DB::DataTypeNumber>(T::FieldType const&, unsigned int) @ 0x0000000013c2e304 5. /build/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*) @ 0x0000000012fd7f3e 6. /build/src/Functions/FunctionsConversion.h:2467: 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&&) @ 0x0000000012f9b2d2 7. /build/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 @ 0x0000000012faebee 8. /build/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 @ 0x0000000012fae41a 9. /build/src/Functions/IFunction.h:437: DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000a069f2a 10. /build/src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000012d9965a 11. /build/src/Functions/IFunction.cpp:351: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d93b02 12. /build/src/Functions/IFunction.cpp:177: DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d93698 13. /build/src/Functions/IFunction.cpp:343: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d93aad 14. /build/src/Functions/IFunction.cpp:420: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d95059 15. /build/src/Functions/IFunction.cpp:498: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d95c72 16. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3567: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000014034494 17. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3838: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000014019a9e 18. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3980: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000014018e31 19. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:4304: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000014042fa7 20. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5605: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000014013749 21. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000140127f9 22. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000014011fce 23. /build/src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000001406ce8a 24. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000014973b42 25. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000001497268d 26. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000014974d24 27. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001492924b 28. /build/src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88641 29. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 30. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 31. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 2025.07.28 11:51:13.748130 [ 11826 ] {} 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. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000000a074fcb 4. /build/src/Core/DecimalFunctions.h:354: T0::FieldType DB::convertFromDecimal>, DB::DataTypeNumber>(T::FieldType const&, unsigned int) @ 0x0000000013c2e304 5. /build/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*) @ 0x0000000012fd7f3e 6. /build/src/Functions/FunctionsConversion.h:2467: 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&&) @ 0x0000000012f9b2d2 7. /build/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 @ 0x0000000012faebee 8. /build/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 @ 0x0000000012fae41a 9. /build/src/Functions/IFunction.h:437: DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000a069f2a 10. /build/src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000012d9965a 11. /build/src/Functions/IFunction.cpp:351: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d93b02 12. /build/src/Functions/IFunction.cpp:177: DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d93698 13. /build/src/Functions/IFunction.cpp:343: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d93aad 14. /build/src/Functions/IFunction.cpp:420: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d95059 15. /build/src/Functions/IFunction.cpp:498: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d95c72 16. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3567: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000014034494 17. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3838: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000014019a9e 18. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3980: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000014018e31 19. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:4304: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000014042fa7 20. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5605: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000014013749 21. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000140127f9 22. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000014011fce 23. /build/src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000001406ce8a 24. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000014973b42 25. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000001497268d 26. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000014974d24 27. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001492924b 28. /build/src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88641 29. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 30. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 31. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 2025.07.28 11:51:13.876969 [ 11826 ] {09b9cbc3-6586-4fea-a9d8-5b217ee0a28c} executeQuery: Code: 407. DB::Exception: Convert overflow: In scope SELECT toDecimal32('-1', 3) AS x, toUInt64(x). (DECIMAL_OVERFLOW) (version 25.3.6.10636.altinitytest (altinity build)) (from [::1]:50820) (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. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000000a074fcb 4. /build/src/Core/DecimalFunctions.h:334: T0::FieldType DB::convertFromDecimal>, DB::DataTypeNumber>(T::FieldType const&, unsigned int) @ 0x0000000013c2ecce 5. /build/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*) @ 0x0000000012ff44be 6. /build/src/Functions/FunctionsConversion.h:2467: 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&&) @ 0x0000000012f9d824 7. /build/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 @ 0x0000000012fb254e 8. /build/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 @ 0x0000000012fb1d7a 9. /build/src/Functions/IFunction.h:437: DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000a069f2a 10. /build/src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000012d9965a 11. /build/src/Functions/IFunction.cpp:351: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d93b02 12. /build/src/Functions/IFunction.cpp:177: DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d93698 13. /build/src/Functions/IFunction.cpp:343: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d93aad 14. /build/src/Functions/IFunction.cpp:420: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d95059 15. /build/src/Functions/IFunction.cpp:498: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d95c72 16. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3567: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000014034494 17. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3838: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000014019a9e 18. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3980: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000014018e31 19. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:4304: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000014042fa7 20. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5605: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000014013749 21. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000140127f9 22. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000014011fce 23. /build/src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000001406ce8a 24. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000014973b42 25. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000001497268d 26. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000014974d24 27. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001492924b 28. /build/src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88641 29. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 30. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 31. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 2025.07.28 11:51:13.883180 [ 11826 ] {} 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. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000000a074fcb 4. /build/src/Core/DecimalFunctions.h:334: T0::FieldType DB::convertFromDecimal>, DB::DataTypeNumber>(T::FieldType const&, unsigned int) @ 0x0000000013c2ecce 5. /build/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*) @ 0x0000000012ff44be 6. /build/src/Functions/FunctionsConversion.h:2467: 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&&) @ 0x0000000012f9d824 7. /build/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 @ 0x0000000012fb254e 8. /build/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 @ 0x0000000012fb1d7a 9. /build/src/Functions/IFunction.h:437: DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000a069f2a 10. /build/src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000012d9965a 11. /build/src/Functions/IFunction.cpp:351: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d93b02 12. /build/src/Functions/IFunction.cpp:177: DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d93698 13. /build/src/Functions/IFunction.cpp:343: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d93aad 14. /build/src/Functions/IFunction.cpp:420: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d95059 15. /build/src/Functions/IFunction.cpp:498: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d95c72 16. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3567: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000014034494 17. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3838: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000014019a9e 18. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3980: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000014018e31 19. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:4304: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000014042fa7 20. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5605: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000014013749 21. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000140127f9 22. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000014011fce 23. /build/src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000001406ce8a 24. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000014973b42 25. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000001497268d 26. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000014974d24 27. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001492924b 28. /build/src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88641 29. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 30. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 31. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 2025.07.28 11:51:14.128742 [ 11826 ] {c93bec4d-9284-4c3c-bc20-c947a843a19e} executeQuery: Code: 407. DB::Exception: Convert overflow: In scope SELECT toDecimal32('-1', 3) AS x, toUInt32(x). (DECIMAL_OVERFLOW) (version 25.3.6.10636.altinitytest (altinity build)) (from [::1]:50820) (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. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000000a074fcb 4. /build/src/Core/DecimalFunctions.h:334: T0::FieldType DB::convertFromDecimal>, DB::DataTypeNumber>(T::FieldType const&, unsigned int) @ 0x0000000013c2e90c 5. /build/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*) @ 0x0000000012feae1e 6. /build/src/Functions/FunctionsConversion.h:2467: 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&&) @ 0x0000000012f9ca84 7. /build/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 @ 0x0000000012fb122e 8. /build/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 @ 0x0000000012fb0a5a 9. /build/src/Functions/IFunction.h:437: DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000a069f2a 10. /build/src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000012d9965a 11. /build/src/Functions/IFunction.cpp:351: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d93b02 12. /build/src/Functions/IFunction.cpp:177: DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d93698 13. /build/src/Functions/IFunction.cpp:343: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d93aad 14. /build/src/Functions/IFunction.cpp:420: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d95059 15. /build/src/Functions/IFunction.cpp:498: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d95c72 16. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3567: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000014034494 17. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3838: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000014019a9e 18. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3980: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000014018e31 19. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:4304: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000014042fa7 20. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5605: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000014013749 21. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000140127f9 22. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000014011fce 23. /build/src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000001406ce8a 24. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000014973b42 25. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000001497268d 26. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000014974d24 27. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001492924b 28. /build/src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88641 29. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 30. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 31. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 2025.07.28 11:51:14.152829 [ 11826 ] {} 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. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000000a074fcb 4. /build/src/Core/DecimalFunctions.h:334: T0::FieldType DB::convertFromDecimal>, DB::DataTypeNumber>(T::FieldType const&, unsigned int) @ 0x0000000013c2e90c 5. /build/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*) @ 0x0000000012feae1e 6. /build/src/Functions/FunctionsConversion.h:2467: 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&&) @ 0x0000000012f9ca84 7. /build/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 @ 0x0000000012fb122e 8. /build/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 @ 0x0000000012fb0a5a 9. /build/src/Functions/IFunction.h:437: DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000a069f2a 10. /build/src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000012d9965a 11. /build/src/Functions/IFunction.cpp:351: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d93b02 12. /build/src/Functions/IFunction.cpp:177: DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d93698 13. /build/src/Functions/IFunction.cpp:343: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d93aad 14. /build/src/Functions/IFunction.cpp:420: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d95059 15. /build/src/Functions/IFunction.cpp:498: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d95c72 16. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3567: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000014034494 17. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3838: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000014019a9e 18. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3980: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000014018e31 19. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:4304: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000014042fa7 20. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5605: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000014013749 21. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000140127f9 22. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000014011fce 23. /build/src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000001406ce8a 24. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000014973b42 25. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000001497268d 26. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000014974d24 27. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001492924b 28. /build/src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88641 29. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 30. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 31. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 2025.07.28 11:51:14.283925 [ 11826 ] {10306d88-90c0-4b47-a893-6f212cc350ae} executeQuery: Code: 407. DB::Exception: Convert overflow: In scope SELECT toDecimal32('-1', 3) AS x, toUInt16(x). (DECIMAL_OVERFLOW) (version 25.3.6.10636.altinitytest (altinity build)) (from [::1]:50820) (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. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000000a074fcb 4. /build/src/Core/DecimalFunctions.h:354: T0::FieldType DB::convertFromDecimal>, DB::DataTypeNumber>(T::FieldType const&, unsigned int) @ 0x0000000013c2e58f 5. /build/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*) @ 0x0000000012fe17e2 6. /build/src/Functions/FunctionsConversion.h:2467: 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&&) @ 0x0000000012f9bce4 7. /build/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 @ 0x0000000012faff0e 8. /build/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 @ 0x0000000012faf73a 9. /build/src/Functions/IFunction.h:437: DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000a069f2a 10. /build/src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000012d9965a 11. /build/src/Functions/IFunction.cpp:351: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d93b02 12. /build/src/Functions/IFunction.cpp:177: DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d93698 13. /build/src/Functions/IFunction.cpp:343: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d93aad 14. /build/src/Functions/IFunction.cpp:420: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d95059 15. /build/src/Functions/IFunction.cpp:498: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d95c72 16. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3567: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000014034494 17. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3838: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000014019a9e 18. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3980: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000014018e31 19. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:4304: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000014042fa7 20. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5605: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000014013749 21. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000140127f9 22. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000014011fce 23. /build/src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000001406ce8a 24. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000014973b42 25. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000001497268d 26. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000014974d24 27. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001492924b 28. /build/src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88641 29. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 30. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 31. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 2025.07.28 11:51:14.299373 [ 11826 ] {} 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. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000000a074fcb 4. /build/src/Core/DecimalFunctions.h:354: T0::FieldType DB::convertFromDecimal>, DB::DataTypeNumber>(T::FieldType const&, unsigned int) @ 0x0000000013c2e58f 5. /build/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*) @ 0x0000000012fe17e2 6. /build/src/Functions/FunctionsConversion.h:2467: 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&&) @ 0x0000000012f9bce4 7. /build/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 @ 0x0000000012faff0e 8. /build/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 @ 0x0000000012faf73a 9. /build/src/Functions/IFunction.h:437: DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000a069f2a 10. /build/src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000012d9965a 11. /build/src/Functions/IFunction.cpp:351: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d93b02 12. /build/src/Functions/IFunction.cpp:177: DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d93698 13. /build/src/Functions/IFunction.cpp:343: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d93aad 14. /build/src/Functions/IFunction.cpp:420: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d95059 15. /build/src/Functions/IFunction.cpp:498: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d95c72 16. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3567: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000014034494 17. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3838: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000014019a9e 18. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3980: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000014018e31 19. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:4304: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000014042fa7 20. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5605: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000014013749 21. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000140127f9 22. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000014011fce 23. /build/src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000001406ce8a 24. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000014973b42 25. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000001497268d 26. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000014974d24 27. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001492924b 28. /build/src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88641 29. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 30. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 31. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 2025.07.28 11:51:14.429220 [ 7625 ] {} 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. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x000000000c25bc4b 4. /build/src/Access/SettingsConstraints.cpp:343: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000138596e3 5. /build/src/Access/SettingsConstraints.cpp:300: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000013858faf 6. /build/src/Access/SettingsConstraints.cpp:209: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x00000000138592b8 7. /build/src/Interpreters/Context.cpp:2690: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000014436134 8. /build/src/Interpreters/Context.cpp:2729: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x000000001443662b 9. /build/src/Server/TCPHandler.cpp:2158: DB::TCPHandler::processQuery(std::optional&) @ 0x00000000168f61df 10. /build/src/Server/TCPHandler.cpp:918: DB::TCPHandler::receivePacketsExpectQuery(std::optional&) @ 0x00000000168ef965 11. /build/src/Server/TCPHandler.cpp:491: DB::TCPHandler::runImpl() @ 0x00000000168e5eb4 12. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 13. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 14. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 16. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 17. ? @ 0x00007fbc6213eac3 18. ? @ 0x00007fbc621d0850 2025.07.28 11:51:14.430709 [ 7625 ] {} 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. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000000a074fcb 4. /build/src/Server/TCPHandler.cpp:897: DB::TCPHandler::receivePacketsExpectQuery(std::optional&) @ 0x00000000168efa89 5. /build/src/Server/TCPHandler.cpp:491: DB::TCPHandler::runImpl() @ 0x00000000168e5eb4 6. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 7. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 8. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 9. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 10. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 11. ? @ 0x00007fbc6213eac3 12. ? @ 0x00007fbc621d0850 2025.07.28 11:51:14.454888 [ 11826 ] {7374e418-56ca-4a2e-b820-467ce050d42a} executeQuery: Code: 407. DB::Exception: Convert overflow: In scope SELECT toDecimal32('-1', 3) AS x, toUInt8(x). (DECIMAL_OVERFLOW) (version 25.3.6.10636.altinitytest (altinity build)) (from [::1]:50820) (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. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000000a074fcb 4. /build/src/Core/DecimalFunctions.h:354: T0::FieldType DB::convertFromDecimal>, DB::DataTypeNumber>(T::FieldType const&, unsigned int) @ 0x0000000013c2e22f 5. /build/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*) @ 0x0000000012fd7abe 6. /build/src/Functions/FunctionsConversion.h:2467: 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&&) @ 0x0000000012f9af12 7. /build/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 @ 0x0000000012faebee 8. /build/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 @ 0x0000000012fae41a 9. /build/src/Functions/IFunction.h:437: DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000a069f2a 10. /build/src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000012d9965a 11. /build/src/Functions/IFunction.cpp:351: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d93b02 12. /build/src/Functions/IFunction.cpp:177: DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d93698 13. /build/src/Functions/IFunction.cpp:343: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d93aad 14. /build/src/Functions/IFunction.cpp:420: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d95059 15. /build/src/Functions/IFunction.cpp:498: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d95c72 16. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3567: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000014034494 17. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3838: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000014019a9e 18. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3980: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000014018e31 19. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:4304: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000014042fa7 20. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5605: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000014013749 21. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000140127f9 22. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000014011fce 23. /build/src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000001406ce8a 24. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000014973b42 25. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000001497268d 26. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000014974d24 27. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001492924b 28. /build/src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88641 29. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 30. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 31. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 2025.07.28 11:51:14.461725 [ 11826 ] {} 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. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000000a074fcb 4. /build/src/Core/DecimalFunctions.h:354: T0::FieldType DB::convertFromDecimal>, DB::DataTypeNumber>(T::FieldType const&, unsigned int) @ 0x0000000013c2e22f 5. /build/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*) @ 0x0000000012fd7abe 6. /build/src/Functions/FunctionsConversion.h:2467: 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&&) @ 0x0000000012f9af12 7. /build/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 @ 0x0000000012faebee 8. /build/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 @ 0x0000000012fae41a 9. /build/src/Functions/IFunction.h:437: DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000a069f2a 10. /build/src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000012d9965a 11. /build/src/Functions/IFunction.cpp:351: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d93b02 12. /build/src/Functions/IFunction.cpp:177: DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d93698 13. /build/src/Functions/IFunction.cpp:343: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d93aad 14. /build/src/Functions/IFunction.cpp:420: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d95059 15. /build/src/Functions/IFunction.cpp:498: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d95c72 16. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3567: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000014034494 17. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3838: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000014019a9e 18. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3980: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000014018e31 19. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:4304: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000014042fa7 20. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5605: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000014013749 21. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000140127f9 22. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000014011fce 23. /build/src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000001406ce8a 24. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000014973b42 25. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000001497268d 26. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000014974d24 27. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001492924b 28. /build/src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88641 29. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 30. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 31. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 2025.07.28 11:51:14.577666 [ 6322 ] {} 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. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x000000000c25bc4b 4. /build/src/Access/SettingsConstraints.cpp:343: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000138596e3 5. /build/src/Access/SettingsConstraints.cpp:300: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000013858faf 6. /build/src/Access/SettingsConstraints.cpp:209: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x00000000138592b8 7. /build/src/Interpreters/Context.cpp:2690: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000014436134 8. /build/src/Interpreters/Context.cpp:2729: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x000000001443662b 9. /build/src/Server/TCPHandler.cpp:2158: DB::TCPHandler::processQuery(std::optional&) @ 0x00000000168f61df 10. /build/src/Server/TCPHandler.cpp:918: DB::TCPHandler::receivePacketsExpectQuery(std::optional&) @ 0x00000000168ef965 11. /build/src/Server/TCPHandler.cpp:491: DB::TCPHandler::runImpl() @ 0x00000000168e5eb4 12. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 13. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 14. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 16. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 17. ? @ 0x00007fbc6213eac3 18. ? @ 0x00007fbc621d0850 2025.07.28 11:51:14.580883 [ 6322 ] {} 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. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000000a074fcb 4. /build/src/Server/TCPHandler.cpp:897: DB::TCPHandler::receivePacketsExpectQuery(std::optional&) @ 0x00000000168efa89 5. /build/src/Server/TCPHandler.cpp:491: DB::TCPHandler::runImpl() @ 0x00000000168e5eb4 6. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 7. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 8. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 9. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 10. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 11. ? @ 0x00007fbc6213eac3 12. ? @ 0x00007fbc621d0850 2025.07.28 11:51:14.669113 [ 11826 ] {1d383fba-476f-4476-b0ae-117bcaa82af8} executeQuery: Code: 407. DB::Exception: Convert overflow: In scope SELECT toDecimal128('18446744073709551616', 0) AS x, toUInt64(x). (DECIMAL_OVERFLOW) (version 25.3.6.10636.altinitytest (altinity build)) (from [::1]:50820) (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. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000000a074fcb 4. /build/src/Core/DecimalFunctions.h:354: void DB::DecimalUtils::convertToImpl>, void>(DB::Decimal> const&, unsigned int, unsigned long&) @ 0x0000000013c2bd4c 5. /build/src/DataTypes/DataTypesDecimal.cpp:217: T0::FieldType DB::convertFromDecimal>>, DB::DataTypeNumber>(T::FieldType const&, unsigned int) @ 0x0000000013c2ede9 6. /build/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*) @ 0x0000000012ff4cc2 7. /build/src/Functions/FunctionsConversion.h:2467: 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&&) @ 0x0000000012f9d7c4 8. /build/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 @ 0x0000000012fb254e 9. /build/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 @ 0x0000000012fb1d7a 10. /build/src/Functions/IFunction.h:437: DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000a069f2a 11. /build/src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000012d9965a 12. /build/src/Functions/IFunction.cpp:351: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d93b02 13. /build/src/Functions/IFunction.cpp:177: DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d93698 14. /build/src/Functions/IFunction.cpp:343: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d93aad 15. /build/src/Functions/IFunction.cpp:420: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d95059 16. /build/src/Functions/IFunction.cpp:498: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d95c72 17. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3567: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000014034494 18. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3838: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000014019a9e 19. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3980: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000014018e31 20. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:4304: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000014042fa7 21. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5605: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000014013749 22. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000140127f9 23. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000014011fce 24. /build/src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000001406ce8a 25. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000014973b42 26. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000001497268d 27. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000014974d24 28. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001492924b 29. /build/src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88641 30. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 31. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 2025.07.28 11:51:14.676105 [ 11826 ] {} 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. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000000a074fcb 4. /build/src/Core/DecimalFunctions.h:354: void DB::DecimalUtils::convertToImpl>, void>(DB::Decimal> const&, unsigned int, unsigned long&) @ 0x0000000013c2bd4c 5. /build/src/DataTypes/DataTypesDecimal.cpp:217: T0::FieldType DB::convertFromDecimal>>, DB::DataTypeNumber>(T::FieldType const&, unsigned int) @ 0x0000000013c2ede9 6. /build/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*) @ 0x0000000012ff4cc2 7. /build/src/Functions/FunctionsConversion.h:2467: 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&&) @ 0x0000000012f9d7c4 8. /build/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 @ 0x0000000012fb254e 9. /build/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 @ 0x0000000012fb1d7a 10. /build/src/Functions/IFunction.h:437: DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000a069f2a 11. /build/src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000012d9965a 12. /build/src/Functions/IFunction.cpp:351: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d93b02 13. /build/src/Functions/IFunction.cpp:177: DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d93698 14. /build/src/Functions/IFunction.cpp:343: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d93aad 15. /build/src/Functions/IFunction.cpp:420: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d95059 16. /build/src/Functions/IFunction.cpp:498: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d95c72 17. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3567: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000014034494 18. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3838: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000014019a9e 19. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3980: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000014018e31 20. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:4304: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000014042fa7 21. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5605: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000014013749 22. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000140127f9 23. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000014011fce 24. /build/src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000001406ce8a 25. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000014973b42 26. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000001497268d 27. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000014974d24 28. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001492924b 29. /build/src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88641 30. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 31. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 2025.07.28 11:51:14.751521 [ 4900 ] {} 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. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x000000000c25bc4b 4. /build/src/Access/SettingsConstraints.cpp:343: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000138596e3 5. /build/src/Access/SettingsConstraints.cpp:300: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000013858faf 6. /build/src/Access/SettingsConstraints.cpp:209: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x00000000138592b8 7. /build/src/Interpreters/Context.cpp:2690: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000014436134 8. /build/src/Interpreters/Context.cpp:2729: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x000000001443662b 9. /build/src/Server/TCPHandler.cpp:2158: DB::TCPHandler::processQuery(std::optional&) @ 0x00000000168f61df 10. /build/src/Server/TCPHandler.cpp:918: DB::TCPHandler::receivePacketsExpectQuery(std::optional&) @ 0x00000000168ef965 11. /build/src/Server/TCPHandler.cpp:491: DB::TCPHandler::runImpl() @ 0x00000000168e5eb4 12. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 13. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 14. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 16. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 17. ? @ 0x00007fbc6213eac3 18. ? @ 0x00007fbc621d0850 2025.07.28 11:51:14.770510 [ 4900 ] {} 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. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000000a074fcb 4. /build/src/Server/TCPHandler.cpp:897: DB::TCPHandler::receivePacketsExpectQuery(std::optional&) @ 0x00000000168efa89 5. /build/src/Server/TCPHandler.cpp:491: DB::TCPHandler::runImpl() @ 0x00000000168e5eb4 6. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 7. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 8. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 9. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 10. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 11. ? @ 0x00007fbc6213eac3 12. ? @ 0x00007fbc621d0850 2025.07.28 11:51:14.783692 [ 5852 ] {9e0b235f-6fb4-43e3-b6fe-3de8eb5cc548} BackupsWorker: Failed to restore from backup Disk('backups', '03145_non_loaded_projection_backup_test_9'): Code: 608. DB::Exception: Cannot restore the table test_9.tp_1 because it already contains some data. You can set structure_only=true or allow_non_empty_tables=true to overcome that in the way you want: While restoring data of table test_9.tp_1. (CANNOT_RESTORE_TABLE), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x000000000a06b56b 4. /build/src/Backups/RestorerFromBackup.cpp:1194: DB::RestorerFromBackup::throwTableIsNotEmpty(DB::StorageID const&) @ 0x0000000013935254 5. /build/src/Storages/MergeTree/MergeTreeData.cpp:5925: DB::MergeTreeData::restoreDataFromBackup(DB::RestorerFromBackup&, String const&, std::optional, 7ul, std::allocator>>> const&) @ 0x000000001635bca6 6. /build/src/Backups/RestorerFromBackup.cpp:1130: DB::RestorerFromBackup::insertDataToTableImpl(DB::QualifiedTableName const&, std::shared_ptr, String const&, std::optional, 7ul, std::allocator>>> const&) @ 0x0000000013934cb0 7. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000013935b2a 8. /build/contrib/llvm-project/libcxx/include/future:1589: std::packaged_task::operator()() @ 0x000000001347c997 9. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc6653 10. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000000fccc4c3 11. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc3d92 12. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fcca080 13. ? @ 0x00007fbc6213eac3 14. ? @ 0x00007fbc621d0850 Job's origin stack trace: 0. /build/src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000000fc33b84 1. /build/src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000000fcc2ea7 2. /build/src/Common/ThreadPool.cpp:401: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fcc7f1c 3. /build/src/Common/ThreadPool.cpp:494: ThreadPoolImpl>::scheduleOrThrowOnError(std::function, Priority) @ 0x000000000fcc7a0e 4. /build/src/Common/threadPoolCallbackRunner.h:52: std::future std::__function::__policy_invoker (DB::RestorerFromBackup::schedule(std::function&&, char const*)::$_0&&, Priority)>::__call_impl[abi:se190107] (DB::RestorerFromBackup::schedule(std::function&&, char const*)::$_0&&, Priority)> DB::threadPoolCallbackRunnerUnsafe&&, char const*)::$_0>(ThreadPoolImpl>&, String const&)::'lambda'(DB::RestorerFromBackup::schedule(std::function&&, char const*)::$_0&&, Priority), std::future (DB::RestorerFromBackup::schedule(std::function&&, char const*)::$_0&&, Priority)>>(std::__function::__policy_storage const*, DB::RestorerFromBackup::schedule(std::function&&, char const*)::$_0&&, Priority&&) @ 0x000000001393560c 5. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001392c011 6. /build/src/Backups/RestorerFromBackup.cpp:1114: DB::RestorerFromBackup::insertDataToTable(DB::QualifiedTableName const&) @ 0x000000001393497a 7. /build/src/Backups/RestorerFromBackup.cpp:1093: DB::RestorerFromBackup::insertDataToTables() @ 0x000000001392b8fb 8. /build/src/Backups/RestorerFromBackup.cpp:176: DB::RestorerFromBackup::run(DB::RestorerFromBackup::Mode) @ 0x0000000013926f4e 9. /build/src/Backups/BackupsWorker.cpp:948: 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&) @ 0x00000000138ae52a 10. /build/src/Backups/BackupsWorker.cpp:793: DB::BackupsWorker::RestoreStarter::doRestore() @ 0x00000000138b8885 11. /build/src/Backups/BackupsWorker.cpp:840: void std::__function::__policy_invoker::__call_impl[abi:se190107] const&, std::shared_ptr)::$_0, void ()>>(std::__function::__policy_storage const*) @ 0x00000000138b2d8c 12. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001347c844 13. /build/contrib/llvm-project/libcxx/include/future:1589: std::packaged_task::operator()() @ 0x000000001347c997 14. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc6653 15. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000000fccc4c3 16. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc3d92 17. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fcca080 18. ? @ 0x00007fbc6213eac3 19. ? @ 0x00007fbc621d0850 Job's origin stack trace: 0. /build/src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000000fc33b84 1. /build/src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000000fcc2ea7 2. /build/src/Common/ThreadPool.cpp:401: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fcc7f1c 3. /build/src/Common/ThreadPool.cpp:494: ThreadPoolImpl>::scheduleOrThrowOnError(std::function, Priority) @ 0x000000000fcc7a0e 4. /build/src/Common/threadPoolCallbackRunner.h:52: std::function (std::function&&, Priority)> DB::threadPoolCallbackRunnerUnsafe>(ThreadPoolImpl>&, String const&)::'lambda'(std::function&&, Priority)::operator()(std::function&&, Priority) @ 0x000000001347c0ca 5. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: std::future std::__function::__policy_invoker (std::function&&, Priority)>::__call_impl[abi:se190107] (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&&) @ 0x000000001347beef 6. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000138a9322 7. /build/src/Backups/BackupsWorker.cpp:335: DB::BackupsWorker::start(std::shared_ptr const&, std::shared_ptr) @ 0x00000000138a8ded 8. /build/src/Interpreters/InterpreterBackupQuery.cpp:44: DB::InterpreterBackupQuery::execute() @ 0x0000000014cfea7d 9. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88dc9 10. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 11. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 12. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 13. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 14. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 16. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 17. ? @ 0x00007fbc6213eac3 18. ? @ 0x00007fbc621d0850 (version 25.3.6.10636.altinitytest (altinity build)) 2025.07.28 11:51:14.852443 [ 4474 ] {} 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. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x000000000c25bc4b 4. /build/src/Access/SettingsConstraints.cpp:343: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000138596e3 5. /build/src/Access/SettingsConstraints.cpp:300: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000013858faf 6. /build/src/Access/SettingsConstraints.cpp:209: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x00000000138592b8 7. /build/src/Interpreters/Context.cpp:2690: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000014436134 8. /build/src/Interpreters/Context.cpp:2729: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x000000001443662b 9. /build/src/Server/TCPHandler.cpp:2158: DB::TCPHandler::processQuery(std::optional&) @ 0x00000000168f61df 10. /build/src/Server/TCPHandler.cpp:918: DB::TCPHandler::receivePacketsExpectQuery(std::optional&) @ 0x00000000168ef965 11. /build/src/Server/TCPHandler.cpp:491: DB::TCPHandler::runImpl() @ 0x00000000168e5eb4 12. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 13. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 14. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 16. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 17. ? @ 0x00007fbc6213eac3 18. ? @ 0x00007fbc621d0850 2025.07.28 11:51:14.853444 [ 4474 ] {} 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. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000000a074fcb 4. /build/src/Server/TCPHandler.cpp:897: DB::TCPHandler::receivePacketsExpectQuery(std::optional&) @ 0x00000000168efa89 5. /build/src/Server/TCPHandler.cpp:491: DB::TCPHandler::runImpl() @ 0x00000000168e5eb4 6. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 7. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 8. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 9. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 10. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 11. ? @ 0x00007fbc6213eac3 12. ? @ 0x00007fbc621d0850 2025.07.28 11:51:14.906877 [ 5747 ] {9e0b235f-6fb4-43e3-b6fe-3de8eb5cc548} executeQuery: Code: 608. DB::Exception: Cannot restore the table test_9.tp_1 because it already contains some data. You can set structure_only=true or allow_non_empty_tables=true to overcome that in the way you want: While restoring data of table test_9.tp_1. (CANNOT_RESTORE_TABLE) (version 25.3.6.10636.altinitytest (altinity build)) (from [::1]:37562) (comment: 03145_non_loaded_projection_backup.sh) (query 3, line 4) (in query: restore table tp_1 from Disk('backups', '03145_non_loaded_projection_backup_test_9');), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x000000000a06b56b 4. /build/src/Backups/RestorerFromBackup.cpp:1194: DB::RestorerFromBackup::throwTableIsNotEmpty(DB::StorageID const&) @ 0x0000000013935254 5. /build/src/Storages/MergeTree/MergeTreeData.cpp:5925: DB::MergeTreeData::restoreDataFromBackup(DB::RestorerFromBackup&, String const&, std::optional, 7ul, std::allocator>>> const&) @ 0x000000001635bca6 6. /build/src/Backups/RestorerFromBackup.cpp:1130: DB::RestorerFromBackup::insertDataToTableImpl(DB::QualifiedTableName const&, std::shared_ptr, String const&, std::optional, 7ul, std::allocator>>> const&) @ 0x0000000013934cb0 7. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000013935b2a 8. /build/contrib/llvm-project/libcxx/include/future:1589: std::packaged_task::operator()() @ 0x000000001347c997 9. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc6653 10. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000000fccc4c3 11. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc3d92 12. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fcca080 13. ? @ 0x00007fbc6213eac3 14. ? @ 0x00007fbc621d0850 2025.07.28 11:51:14.916921 [ 5747 ] {} TCPHandler: Code: 608. DB::Exception: Cannot restore the table test_9.tp_1 because it already contains some data. You can set structure_only=true or allow_non_empty_tables=true to overcome that in the way you want: While restoring data of table test_9.tp_1. (CANNOT_RESTORE_TABLE), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x000000000a06b56b 4. /build/src/Backups/RestorerFromBackup.cpp:1194: DB::RestorerFromBackup::throwTableIsNotEmpty(DB::StorageID const&) @ 0x0000000013935254 5. /build/src/Storages/MergeTree/MergeTreeData.cpp:5925: DB::MergeTreeData::restoreDataFromBackup(DB::RestorerFromBackup&, String const&, std::optional, 7ul, std::allocator>>> const&) @ 0x000000001635bca6 6. /build/src/Backups/RestorerFromBackup.cpp:1130: DB::RestorerFromBackup::insertDataToTableImpl(DB::QualifiedTableName const&, std::shared_ptr, String const&, std::optional, 7ul, std::allocator>>> const&) @ 0x0000000013934cb0 7. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000013935b2a 8. /build/contrib/llvm-project/libcxx/include/future:1589: std::packaged_task::operator()() @ 0x000000001347c997 9. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc6653 10. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000000fccc4c3 11. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc3d92 12. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fcca080 13. ? @ 0x00007fbc6213eac3 14. ? @ 0x00007fbc621d0850 Job's origin stack trace: 0. /build/src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000000fc33b84 1. /build/src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000000fcc2ea7 2. /build/src/Common/ThreadPool.cpp:401: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fcc7f1c 3. /build/src/Common/ThreadPool.cpp:494: ThreadPoolImpl>::scheduleOrThrowOnError(std::function, Priority) @ 0x000000000fcc7a0e 4. /build/src/Common/threadPoolCallbackRunner.h:52: std::future std::__function::__policy_invoker (DB::RestorerFromBackup::schedule(std::function&&, char const*)::$_0&&, Priority)>::__call_impl[abi:se190107] (DB::RestorerFromBackup::schedule(std::function&&, char const*)::$_0&&, Priority)> DB::threadPoolCallbackRunnerUnsafe&&, char const*)::$_0>(ThreadPoolImpl>&, String const&)::'lambda'(DB::RestorerFromBackup::schedule(std::function&&, char const*)::$_0&&, Priority), std::future (DB::RestorerFromBackup::schedule(std::function&&, char const*)::$_0&&, Priority)>>(std::__function::__policy_storage const*, DB::RestorerFromBackup::schedule(std::function&&, char const*)::$_0&&, Priority&&) @ 0x000000001393560c 5. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001392c011 6. /build/src/Backups/RestorerFromBackup.cpp:1114: DB::RestorerFromBackup::insertDataToTable(DB::QualifiedTableName const&) @ 0x000000001393497a 7. /build/src/Backups/RestorerFromBackup.cpp:1093: DB::RestorerFromBackup::insertDataToTables() @ 0x000000001392b8fb 8. /build/src/Backups/RestorerFromBackup.cpp:176: DB::RestorerFromBackup::run(DB::RestorerFromBackup::Mode) @ 0x0000000013926f4e 9. /build/src/Backups/BackupsWorker.cpp:948: 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&) @ 0x00000000138ae52a 10. /build/src/Backups/BackupsWorker.cpp:793: DB::BackupsWorker::RestoreStarter::doRestore() @ 0x00000000138b8885 11. /build/src/Backups/BackupsWorker.cpp:840: void std::__function::__policy_invoker::__call_impl[abi:se190107] const&, std::shared_ptr)::$_0, void ()>>(std::__function::__policy_storage const*) @ 0x00000000138b2d8c 12. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001347c844 13. /build/contrib/llvm-project/libcxx/include/future:1589: std::packaged_task::operator()() @ 0x000000001347c997 14. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc6653 15. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000000fccc4c3 16. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc3d92 17. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fcca080 18. ? @ 0x00007fbc6213eac3 19. ? @ 0x00007fbc621d0850 Job's origin stack trace: 0. /build/src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000000fc33b84 1. /build/src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000000fcc2ea7 2. /build/src/Common/ThreadPool.cpp:401: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fcc7f1c 3. /build/src/Common/ThreadPool.cpp:494: ThreadPoolImpl>::scheduleOrThrowOnError(std::function, Priority) @ 0x000000000fcc7a0e 4. /build/src/Common/threadPoolCallbackRunner.h:52: std::function (std::function&&, Priority)> DB::threadPoolCallbackRunnerUnsafe>(ThreadPoolImpl>&, String const&)::'lambda'(std::function&&, Priority)::operator()(std::function&&, Priority) @ 0x000000001347c0ca 5. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: std::future std::__function::__policy_invoker (std::function&&, Priority)>::__call_impl[abi:se190107] (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&&) @ 0x000000001347beef 6. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000138a9322 7. /build/src/Backups/BackupsWorker.cpp:335: DB::BackupsWorker::start(std::shared_ptr const&, std::shared_ptr) @ 0x00000000138a8ded 8. /build/src/Interpreters/InterpreterBackupQuery.cpp:44: DB::InterpreterBackupQuery::execute() @ 0x0000000014cfea7d 9. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88dc9 10. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 11. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 12. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 13. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 14. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 16. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 17. ? @ 0x00007fbc6213eac3 18. ? @ 0x00007fbc621d0850 2025.07.28 11:51:14.974186 [ 11826 ] {26f295eb-3188-4e9b-b59c-b6ba8fb85ce5} executeQuery: Code: 407. DB::Exception: Convert overflow: In scope SELECT toDecimal128('18446744073709551616', 8) AS x, toUInt64(x). (DECIMAL_OVERFLOW) (version 25.3.6.10636.altinitytest (altinity build)) (from [::1]:50820) (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. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000000a074fcb 4. /build/src/Core/DecimalFunctions.h:354: void DB::DecimalUtils::convertToImpl>, void>(DB::Decimal> const&, unsigned int, unsigned long&) @ 0x0000000013c2bd4c 5. /build/src/DataTypes/DataTypesDecimal.cpp:217: T0::FieldType DB::convertFromDecimal>>, DB::DataTypeNumber>(T::FieldType const&, unsigned int) @ 0x0000000013c2ede9 6. /build/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*) @ 0x0000000012ff4cc2 7. /build/src/Functions/FunctionsConversion.h:2467: 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&&) @ 0x0000000012f9d7c4 8. /build/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 @ 0x0000000012fb254e 9. /build/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 @ 0x0000000012fb1d7a 10. /build/src/Functions/IFunction.h:437: DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000a069f2a 11. /build/src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000012d9965a 12. /build/src/Functions/IFunction.cpp:351: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d93b02 13. /build/src/Functions/IFunction.cpp:177: DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d93698 14. /build/src/Functions/IFunction.cpp:343: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d93aad 15. /build/src/Functions/IFunction.cpp:420: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d95059 16. /build/src/Functions/IFunction.cpp:498: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d95c72 17. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3567: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000014034494 18. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3838: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000014019a9e 19. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3980: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000014018e31 20. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:4304: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000014042fa7 21. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5605: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000014013749 22. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000140127f9 23. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000014011fce 24. /build/src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000001406ce8a 25. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000014973b42 26. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000001497268d 27. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000014974d24 28. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001492924b 29. /build/src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88641 30. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 31. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 2025.07.28 11:51:14.977783 [ 11826 ] {} 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. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000000a074fcb 4. /build/src/Core/DecimalFunctions.h:354: void DB::DecimalUtils::convertToImpl>, void>(DB::Decimal> const&, unsigned int, unsigned long&) @ 0x0000000013c2bd4c 5. /build/src/DataTypes/DataTypesDecimal.cpp:217: T0::FieldType DB::convertFromDecimal>>, DB::DataTypeNumber>(T::FieldType const&, unsigned int) @ 0x0000000013c2ede9 6. /build/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*) @ 0x0000000012ff4cc2 7. /build/src/Functions/FunctionsConversion.h:2467: 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&&) @ 0x0000000012f9d7c4 8. /build/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 @ 0x0000000012fb254e 9. /build/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 @ 0x0000000012fb1d7a 10. /build/src/Functions/IFunction.h:437: DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000a069f2a 11. /build/src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000012d9965a 12. /build/src/Functions/IFunction.cpp:351: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d93b02 13. /build/src/Functions/IFunction.cpp:177: DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d93698 14. /build/src/Functions/IFunction.cpp:343: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d93aad 15. /build/src/Functions/IFunction.cpp:420: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d95059 16. /build/src/Functions/IFunction.cpp:498: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d95c72 17. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3567: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000014034494 18. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3838: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000014019a9e 19. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3980: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000014018e31 20. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:4304: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000014042fa7 21. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5605: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000014013749 22. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000140127f9 23. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000014011fce 24. /build/src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000001406ce8a 25. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000014973b42 26. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000001497268d 27. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000014974d24 28. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001492924b 29. /build/src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88641 30. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 31. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 2025.07.28 11:51:15.014430 [ 4474 ] {} 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. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x000000000c25bc4b 4. /build/src/Access/SettingsConstraints.cpp:343: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000138596e3 5. /build/src/Access/SettingsConstraints.cpp:300: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000013858faf 6. /build/src/Access/SettingsConstraints.cpp:209: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x00000000138592b8 7. /build/src/Interpreters/Context.cpp:2690: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000014436134 8. /build/src/Interpreters/Context.cpp:2729: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x000000001443662b 9. /build/src/Server/TCPHandler.cpp:2158: DB::TCPHandler::processQuery(std::optional&) @ 0x00000000168f61df 10. /build/src/Server/TCPHandler.cpp:918: DB::TCPHandler::receivePacketsExpectQuery(std::optional&) @ 0x00000000168ef965 11. /build/src/Server/TCPHandler.cpp:491: DB::TCPHandler::runImpl() @ 0x00000000168e5eb4 12. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 13. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 14. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 16. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 17. ? @ 0x00007fbc6213eac3 18. ? @ 0x00007fbc621d0850 2025.07.28 11:51:15.021425 [ 7625 ] {fe0b7ae8-4888-4eae-ad20-4e3b3a279745} executeQuery: Code: 6. DB::Exception: Cannot parse string 'Test' as UInt64: syntax error at begin of string. Note: there are toUInt64OrZero and toUInt64OrNull functions, which returns zero/NULL instead of throwing exception.: In scope WITH map(1, 'Test') AS value, 'Array(Tuple(UInt64, UInt64))' AS type SELECT value, CAST(value, type), CAST(materialize(value), type). (CANNOT_PARSE_TEXT) (version 25.3.6.10636.altinitytest (altinity build)) (from [::1]:37592) (comment: 02179_map_cast_to_array.sql) (query 2, line 4) (in query: WITH map(1, 'Test') AS value, 'Array(Tuple(UInt64, UInt64))' AS type SELECT value, cast(value, type), cast(materialize(value), type);), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Functions/FunctionsConversion.h:796: DB::detail::throwExceptionForIncompletelyParsedValue(DB::ReadBuffer&, DB::IDataType const&) @ 0x000000000a150a93 4. /build/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*) @ 0x0000000012ff668a 5. /build/src/Functions/FunctionsConversion.h:1580: COW::immutable_ptr DB::detail::ConvertImpl, DB::detail::NameToUInt64, (DB::FormatSettings::DateTimeOverflowBehavior)0>::execute(std::vector> const&, std::shared_ptr const&, unsigned long, DB::detail::BehaviourOnErrorFromString, void*) @ 0x0000000012ff637e 6. /build/src/Functions/FunctionsConversion.h:2472: 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&&) @ 0x0000000012f9da04 7. /build/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 @ 0x0000000012fb254e 8. /build/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 @ 0x0000000012fb1d7a 9. /build/src/Functions/IFunctionAdaptors.cpp:10: DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000012d995fa 10. /build/src/Functions/IFunction.cpp:353: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d93b52 11. /build/src/Functions/IFunction.cpp:420: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d95059 12. /build/src/Functions/IFunction.cpp:498: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d95c72 13. /build/src/Functions/IFunction.cpp:513: DB::IFunctionBase::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d96059 14. /build/src/Functions/FunctionsConversion.h:3487: COW::immutable_ptr std::__function::__policy_invoker::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)>::__call_impl[abi:se190107], 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) @ 0x0000000012e00996 15. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000012f7f8f2 16. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: COW::immutable_ptr std::__function::__policy_invoker::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)>::__call_impl[abi:se190107] const&, DB::DataTypeTuple 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) @ 0x0000000012f7f44c 17. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000012f7e38a 18. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: COW::immutable_ptr std::__function::__policy_invoker::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)>::__call_impl[abi:se190107] const&, DB::DataTypeArray 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) @ 0x0000000012f7e0ec 19. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000012ddcb1b 20. /build/src/Functions/IFunction.h:57: DB::IExecutableFunction::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000a08134a 21. /build/src/Functions/IFunction.cpp:351: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d93b02 22. /build/src/Functions/IFunction.cpp:177: DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d93698 23. /build/src/Functions/IFunction.cpp:343: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d93aad 24. /build/src/Functions/IFunction.cpp:424: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d94e1b 25. /build/src/Functions/IFunction.cpp:498: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d95c72 26. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3567: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000014034494 27. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3838: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000014019a9e 28. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3980: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000014018e31 29. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:4304: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000014042fa7 30. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5605: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000014013749 31. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000140127f9 2025.07.28 11:51:15.025817 [ 4474 ] {} 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. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000000a074fcb 4. /build/src/Server/TCPHandler.cpp:897: DB::TCPHandler::receivePacketsExpectQuery(std::optional&) @ 0x00000000168efa89 5. /build/src/Server/TCPHandler.cpp:491: DB::TCPHandler::runImpl() @ 0x00000000168e5eb4 6. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 7. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 8. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 9. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 10. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 11. ? @ 0x00007fbc6213eac3 12. ? @ 0x00007fbc621d0850 2025.07.28 11:51:15.046709 [ 7625 ] {} TCPHandler: Code: 6. DB::Exception: Cannot parse string 'Test' as UInt64: syntax error at begin of string. Note: there are toUInt64OrZero and toUInt64OrNull functions, which returns zero/NULL instead of throwing exception.: In scope WITH map(1, 'Test') AS value, 'Array(Tuple(UInt64, UInt64))' AS type SELECT value, CAST(value, type), CAST(materialize(value), type). (CANNOT_PARSE_TEXT), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Functions/FunctionsConversion.h:796: DB::detail::throwExceptionForIncompletelyParsedValue(DB::ReadBuffer&, DB::IDataType const&) @ 0x000000000a150a93 4. /build/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*) @ 0x0000000012ff668a 5. /build/src/Functions/FunctionsConversion.h:1580: COW::immutable_ptr DB::detail::ConvertImpl, DB::detail::NameToUInt64, (DB::FormatSettings::DateTimeOverflowBehavior)0>::execute(std::vector> const&, std::shared_ptr const&, unsigned long, DB::detail::BehaviourOnErrorFromString, void*) @ 0x0000000012ff637e 6. /build/src/Functions/FunctionsConversion.h:2472: 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&&) @ 0x0000000012f9da04 7. /build/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 @ 0x0000000012fb254e 8. /build/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 @ 0x0000000012fb1d7a 9. /build/src/Functions/IFunctionAdaptors.cpp:10: DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000012d995fa 10. /build/src/Functions/IFunction.cpp:353: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d93b52 11. /build/src/Functions/IFunction.cpp:420: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d95059 12. /build/src/Functions/IFunction.cpp:498: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d95c72 13. /build/src/Functions/IFunction.cpp:513: DB::IFunctionBase::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d96059 14. /build/src/Functions/FunctionsConversion.h:3487: COW::immutable_ptr std::__function::__policy_invoker::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)>::__call_impl[abi:se190107], 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) @ 0x0000000012e00996 15. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000012f7f8f2 16. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: COW::immutable_ptr std::__function::__policy_invoker::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)>::__call_impl[abi:se190107] const&, DB::DataTypeTuple 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) @ 0x0000000012f7f44c 17. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000012f7e38a 18. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: COW::immutable_ptr std::__function::__policy_invoker::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)>::__call_impl[abi:se190107] const&, DB::DataTypeArray 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) @ 0x0000000012f7e0ec 19. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000012ddcb1b 20. /build/src/Functions/IFunction.h:57: DB::IExecutableFunction::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000a08134a 21. /build/src/Functions/IFunction.cpp:351: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d93b02 22. /build/src/Functions/IFunction.cpp:177: DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d93698 23. /build/src/Functions/IFunction.cpp:343: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d93aad 24. /build/src/Functions/IFunction.cpp:424: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d94e1b 25. /build/src/Functions/IFunction.cpp:498: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d95c72 26. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3567: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000014034494 27. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3838: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000014019a9e 28. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3980: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000014018e31 29. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:4304: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000014042fa7 30. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5605: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000014013749 31. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000140127f9 2025.07.28 11:51:15.324234 [ 4474 ] {} 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. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x000000000c25bc4b 4. /build/src/Access/SettingsConstraints.cpp:343: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000138596e3 5. /build/src/Access/SettingsConstraints.cpp:300: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000013858faf 6. /build/src/Access/SettingsConstraints.cpp:209: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x00000000138592b8 7. /build/src/Interpreters/Context.cpp:2690: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000014436134 8. /build/src/Interpreters/Context.cpp:2729: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x000000001443662b 9. /build/src/Server/TCPHandler.cpp:2158: DB::TCPHandler::processQuery(std::optional&) @ 0x00000000168f61df 10. /build/src/Server/TCPHandler.cpp:918: DB::TCPHandler::receivePacketsExpectQuery(std::optional&) @ 0x00000000168ef965 11. /build/src/Server/TCPHandler.cpp:491: DB::TCPHandler::runImpl() @ 0x00000000168e5eb4 12. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 13. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 14. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 16. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 17. ? @ 0x00007fbc6213eac3 18. ? @ 0x00007fbc621d0850 2025.07.28 11:51:15.325109 [ 4474 ] {} 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. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000000a074fcb 4. /build/src/Server/TCPHandler.cpp:897: DB::TCPHandler::receivePacketsExpectQuery(std::optional&) @ 0x00000000168efa89 5. /build/src/Server/TCPHandler.cpp:491: DB::TCPHandler::runImpl() @ 0x00000000168e5eb4 6. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 7. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 8. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 9. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 10. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 11. ? @ 0x00007fbc6213eac3 12. ? @ 0x00007fbc621d0850 2025.07.28 11:51:15.330835 [ 11826 ] {02b38919-0a0d-41ec-b18d-b69963b27445} executeQuery: Code: 407. DB::Exception: Convert overflow: In scope SELECT toDecimal128('4294967296', 0) AS x, toUInt32(x). (DECIMAL_OVERFLOW) (version 25.3.6.10636.altinitytest (altinity build)) (from [::1]:50820) (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. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000000a074fcb 4. /build/src/Core/DecimalFunctions.h:354: void DB::DecimalUtils::convertToImpl>, void>(DB::Decimal> const&, unsigned int, unsigned int&) @ 0x0000000013c28e4b 5. /build/src/DataTypes/DataTypesDecimal.cpp:217: T0::FieldType DB::convertFromDecimal>>, DB::DataTypeNumber>(T::FieldType const&, unsigned int) @ 0x0000000013c2ea2b 6. /build/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*) @ 0x0000000012feb642 7. /build/src/Functions/FunctionsConversion.h:2467: 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&&) @ 0x0000000012f9ca24 8. /build/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 @ 0x0000000012fb122e 9. /build/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 @ 0x0000000012fb0a5a 10. /build/src/Functions/IFunction.h:437: DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000a069f2a 11. /build/src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000012d9965a 12. /build/src/Functions/IFunction.cpp:351: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d93b02 13. /build/src/Functions/IFunction.cpp:177: DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d93698 14. /build/src/Functions/IFunction.cpp:343: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d93aad 15. /build/src/Functions/IFunction.cpp:420: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d95059 16. /build/src/Functions/IFunction.cpp:498: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d95c72 17. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3567: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000014034494 18. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3838: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000014019a9e 19. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3980: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000014018e31 20. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:4304: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000014042fa7 21. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5605: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000014013749 22. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000140127f9 23. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000014011fce 24. /build/src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000001406ce8a 25. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000014973b42 26. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000001497268d 27. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000014974d24 28. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001492924b 29. /build/src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88641 30. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 31. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 2025.07.28 11:51:15.349245 [ 11826 ] {} 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. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000000a074fcb 4. /build/src/Core/DecimalFunctions.h:354: void DB::DecimalUtils::convertToImpl>, void>(DB::Decimal> const&, unsigned int, unsigned int&) @ 0x0000000013c28e4b 5. /build/src/DataTypes/DataTypesDecimal.cpp:217: T0::FieldType DB::convertFromDecimal>>, DB::DataTypeNumber>(T::FieldType const&, unsigned int) @ 0x0000000013c2ea2b 6. /build/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*) @ 0x0000000012feb642 7. /build/src/Functions/FunctionsConversion.h:2467: 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&&) @ 0x0000000012f9ca24 8. /build/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 @ 0x0000000012fb122e 9. /build/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 @ 0x0000000012fb0a5a 10. /build/src/Functions/IFunction.h:437: DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000a069f2a 11. /build/src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000012d9965a 12. /build/src/Functions/IFunction.cpp:351: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d93b02 13. /build/src/Functions/IFunction.cpp:177: DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d93698 14. /build/src/Functions/IFunction.cpp:343: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d93aad 15. /build/src/Functions/IFunction.cpp:420: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d95059 16. /build/src/Functions/IFunction.cpp:498: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d95c72 17. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3567: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000014034494 18. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3838: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000014019a9e 19. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3980: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000014018e31 20. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:4304: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000014042fa7 21. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5605: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000014013749 22. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000140127f9 23. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000014011fce 24. /build/src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000001406ce8a 25. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000014973b42 26. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000001497268d 27. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000014974d24 28. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001492924b 29. /build/src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88641 30. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 31. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 2025.07.28 11:51:15.558522 [ 4474 ] {} 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. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x000000000c25bc4b 4. /build/src/Access/SettingsConstraints.cpp:343: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000138596e3 5. /build/src/Access/SettingsConstraints.cpp:300: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000013858faf 6. /build/src/Access/SettingsConstraints.cpp:209: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x00000000138592b8 7. /build/src/Interpreters/Context.cpp:2690: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000014436134 8. /build/src/Interpreters/Context.cpp:2729: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x000000001443662b 9. /build/src/Server/TCPHandler.cpp:2158: DB::TCPHandler::processQuery(std::optional&) @ 0x00000000168f61df 10. /build/src/Server/TCPHandler.cpp:918: DB::TCPHandler::receivePacketsExpectQuery(std::optional&) @ 0x00000000168ef965 11. /build/src/Server/TCPHandler.cpp:491: DB::TCPHandler::runImpl() @ 0x00000000168e5eb4 12. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 13. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 14. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 16. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 17. ? @ 0x00007fbc6213eac3 18. ? @ 0x00007fbc621d0850 2025.07.28 11:51:15.564087 [ 4474 ] {} 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. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000000a074fcb 4. /build/src/Server/TCPHandler.cpp:897: DB::TCPHandler::receivePacketsExpectQuery(std::optional&) @ 0x00000000168efa89 5. /build/src/Server/TCPHandler.cpp:491: DB::TCPHandler::runImpl() @ 0x00000000168e5eb4 6. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 7. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 8. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 9. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 10. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 11. ? @ 0x00007fbc6213eac3 12. ? @ 0x00007fbc621d0850 2025.07.28 11:51:15.631928 [ 11826 ] {27428e95-dc64-4499-9250-17b613819795} executeQuery: Code: 407. DB::Exception: Convert overflow: In scope SELECT toDecimal128('4294967296', 10) AS x, toUInt32(x). (DECIMAL_OVERFLOW) (version 25.3.6.10636.altinitytest (altinity build)) (from [::1]:50820) (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. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000000a074fcb 4. /build/src/Core/DecimalFunctions.h:354: void DB::DecimalUtils::convertToImpl>, void>(DB::Decimal> const&, unsigned int, unsigned int&) @ 0x0000000013c28e4b 5. /build/src/DataTypes/DataTypesDecimal.cpp:217: T0::FieldType DB::convertFromDecimal>>, DB::DataTypeNumber>(T::FieldType const&, unsigned int) @ 0x0000000013c2ea2b 6. /build/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*) @ 0x0000000012feb642 7. /build/src/Functions/FunctionsConversion.h:2467: 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&&) @ 0x0000000012f9ca24 8. /build/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 @ 0x0000000012fb122e 9. /build/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 @ 0x0000000012fb0a5a 10. /build/src/Functions/IFunction.h:437: DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000a069f2a 11. /build/src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000012d9965a 12. /build/src/Functions/IFunction.cpp:351: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d93b02 13. /build/src/Functions/IFunction.cpp:177: DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d93698 14. /build/src/Functions/IFunction.cpp:343: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d93aad 15. /build/src/Functions/IFunction.cpp:420: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d95059 16. /build/src/Functions/IFunction.cpp:498: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d95c72 17. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3567: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000014034494 18. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3838: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000014019a9e 19. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3980: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000014018e31 20. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:4304: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000014042fa7 21. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5605: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000014013749 22. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000140127f9 23. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000014011fce 24. /build/src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000001406ce8a 25. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000014973b42 26. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000001497268d 27. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000014974d24 28. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001492924b 29. /build/src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88641 30. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 31. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 2025.07.28 11:51:15.641104 [ 11826 ] {} 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. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000000a074fcb 4. /build/src/Core/DecimalFunctions.h:354: void DB::DecimalUtils::convertToImpl>, void>(DB::Decimal> const&, unsigned int, unsigned int&) @ 0x0000000013c28e4b 5. /build/src/DataTypes/DataTypesDecimal.cpp:217: T0::FieldType DB::convertFromDecimal>>, DB::DataTypeNumber>(T::FieldType const&, unsigned int) @ 0x0000000013c2ea2b 6. /build/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*) @ 0x0000000012feb642 7. /build/src/Functions/FunctionsConversion.h:2467: 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&&) @ 0x0000000012f9ca24 8. /build/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 @ 0x0000000012fb122e 9. /build/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 @ 0x0000000012fb0a5a 10. /build/src/Functions/IFunction.h:437: DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000a069f2a 11. /build/src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000012d9965a 12. /build/src/Functions/IFunction.cpp:351: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d93b02 13. /build/src/Functions/IFunction.cpp:177: DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d93698 14. /build/src/Functions/IFunction.cpp:343: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d93aad 15. /build/src/Functions/IFunction.cpp:420: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d95059 16. /build/src/Functions/IFunction.cpp:498: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d95c72 17. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3567: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000014034494 18. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3838: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000014019a9e 19. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3980: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000014018e31 20. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:4304: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000014042fa7 21. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5605: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000014013749 22. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000140127f9 23. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000014011fce 24. /build/src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000001406ce8a 25. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000014973b42 26. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000001497268d 27. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000014974d24 28. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001492924b 29. /build/src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88641 30. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 31. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 2025.07.28 11:51:15.750656 [ 4900 ] {} 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. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x000000000c25bc4b 4. /build/src/Access/SettingsConstraints.cpp:343: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000138596e3 5. /build/src/Access/SettingsConstraints.cpp:300: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000013858faf 6. /build/src/Access/SettingsConstraints.cpp:209: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x00000000138592b8 7. /build/src/Interpreters/Context.cpp:2690: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000014436134 8. /build/src/Interpreters/Context.cpp:2729: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x000000001443662b 9. /build/src/Server/TCPHandler.cpp:2158: DB::TCPHandler::processQuery(std::optional&) @ 0x00000000168f61df 10. /build/src/Server/TCPHandler.cpp:918: DB::TCPHandler::receivePacketsExpectQuery(std::optional&) @ 0x00000000168ef965 11. /build/src/Server/TCPHandler.cpp:491: DB::TCPHandler::runImpl() @ 0x00000000168e5eb4 12. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 13. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 14. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 16. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 17. ? @ 0x00007fbc6213eac3 18. ? @ 0x00007fbc621d0850 2025.07.28 11:51:15.754320 [ 4900 ] {} 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. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000000a074fcb 4. /build/src/Server/TCPHandler.cpp:897: DB::TCPHandler::receivePacketsExpectQuery(std::optional&) @ 0x00000000168efa89 5. /build/src/Server/TCPHandler.cpp:491: DB::TCPHandler::runImpl() @ 0x00000000168e5eb4 6. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 7. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 8. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 9. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 10. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 11. ? @ 0x00007fbc6213eac3 12. ? @ 0x00007fbc621d0850 2025.07.28 11:51:15.850356 [ 7395 ] {b19391fb-269d-4eb6-9f6e-1bf094bf6432} InterpreterCheckQuery: Check query for table test_9.tp_1 (6084bb2c-7960-43f7-b13d-0f487ee1618d) 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.6.10636.altinitytest (altinity build)) 2025.07.28 11:51:15.957182 [ 11826 ] {6fbc97fc-6a3a-4a6e-ad0b-9dfd0119d6a3} executeQuery: Code: 407. DB::Exception: Convert overflow: In scope SELECT toDecimal64('4294967296', 0) AS x, toUInt32(x). (DECIMAL_OVERFLOW) (version 25.3.6.10636.altinitytest (altinity build)) (from [::1]:50820) (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. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000000a074fcb 4. /build/src/Core/DecimalFunctions.h:354: T0::FieldType DB::convertFromDecimal>, DB::DataTypeNumber>(T::FieldType const&, unsigned int) @ 0x0000000013c2e9de 5. /build/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*) @ 0x0000000012feb222 6. /build/src/Functions/FunctionsConversion.h:2467: 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&&) @ 0x0000000012f9ce24 7. /build/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 @ 0x0000000012fb122e 8. /build/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 @ 0x0000000012fb0a5a 9. /build/src/Functions/IFunction.h:437: DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000a069f2a 10. /build/src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000012d9965a 11. /build/src/Functions/IFunction.cpp:351: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d93b02 12. /build/src/Functions/IFunction.cpp:177: DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d93698 13. /build/src/Functions/IFunction.cpp:343: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d93aad 14. /build/src/Functions/IFunction.cpp:420: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d95059 15. /build/src/Functions/IFunction.cpp:498: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d95c72 16. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3567: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000014034494 17. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3838: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000014019a9e 18. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3980: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000014018e31 19. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:4304: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000014042fa7 20. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5605: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000014013749 21. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000140127f9 22. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000014011fce 23. /build/src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000001406ce8a 24. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000014973b42 25. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000001497268d 26. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000014974d24 27. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001492924b 28. /build/src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88641 29. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 30. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 31. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 2025.07.28 11:51:15.961874 [ 11826 ] {} 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. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000000a074fcb 4. /build/src/Core/DecimalFunctions.h:354: T0::FieldType DB::convertFromDecimal>, DB::DataTypeNumber>(T::FieldType const&, unsigned int) @ 0x0000000013c2e9de 5. /build/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*) @ 0x0000000012feb222 6. /build/src/Functions/FunctionsConversion.h:2467: 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&&) @ 0x0000000012f9ce24 7. /build/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 @ 0x0000000012fb122e 8. /build/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 @ 0x0000000012fb0a5a 9. /build/src/Functions/IFunction.h:437: DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000a069f2a 10. /build/src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000012d9965a 11. /build/src/Functions/IFunction.cpp:351: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d93b02 12. /build/src/Functions/IFunction.cpp:177: DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d93698 13. /build/src/Functions/IFunction.cpp:343: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d93aad 14. /build/src/Functions/IFunction.cpp:420: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d95059 15. /build/src/Functions/IFunction.cpp:498: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d95c72 16. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3567: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000014034494 17. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3838: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000014019a9e 18. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3980: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000014018e31 19. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:4304: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000014042fa7 20. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5605: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000014013749 21. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000140127f9 22. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000014011fce 23. /build/src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000001406ce8a 24. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000014973b42 25. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000001497268d 26. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000014974d24 27. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001492924b 28. /build/src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88641 29. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 30. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 31. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 2025.07.28 11:51:16.048946 [ 4474 ] {} 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. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x000000000c25bc4b 4. /build/src/Access/SettingsConstraints.cpp:343: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000138596e3 5. /build/src/Access/SettingsConstraints.cpp:300: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000013858faf 6. /build/src/Access/SettingsConstraints.cpp:209: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x00000000138592b8 7. /build/src/Interpreters/Context.cpp:2690: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000014436134 8. /build/src/Interpreters/Context.cpp:2729: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x000000001443662b 9. /build/src/Server/TCPHandler.cpp:2158: DB::TCPHandler::processQuery(std::optional&) @ 0x00000000168f61df 10. /build/src/Server/TCPHandler.cpp:918: DB::TCPHandler::receivePacketsExpectQuery(std::optional&) @ 0x00000000168ef965 11. /build/src/Server/TCPHandler.cpp:491: DB::TCPHandler::runImpl() @ 0x00000000168e5eb4 12. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 13. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 14. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 16. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 17. ? @ 0x00007fbc6213eac3 18. ? @ 0x00007fbc621d0850 2025.07.28 11:51:16.049849 [ 4474 ] {} 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. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000000a074fcb 4. /build/src/Server/TCPHandler.cpp:897: DB::TCPHandler::receivePacketsExpectQuery(std::optional&) @ 0x00000000168efa89 5. /build/src/Server/TCPHandler.cpp:491: DB::TCPHandler::runImpl() @ 0x00000000168e5eb4 6. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 7. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 8. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 9. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 10. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 11. ? @ 0x00007fbc6213eac3 12. ? @ 0x00007fbc621d0850 2025.07.28 11:51:16.110414 [ 7630 ] {d1345b61-5314-409c-bfe3-0707530dd2cf} executeQuery: Code: 62. DB::Exception: Max query size exceeded (can be increased with the `max_query_size` setting): Syntax error: failed at position 1048577 (-): -. . (SYNTAX_ERROR) (version 25.3.6.10636.altinitytest (altinity build)) (from [::ffff:127.0.0.1]:33920) (in query: select 1 in (1, 1, ... (truncated 948624 characters)), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:111: DB::Exception::createDeprecated(String const&, int, bool) @ 0x000000000a08e96d 3. /build/src/Parsers/parseQuery.cpp:411: DB::parseQueryAndMovePosition(DB::IParser&, char const*&, char const*, String const&, bool, unsigned long, unsigned long, unsigned long) @ 0x0000000017a96b2c 4. /build/src/Parsers/parseQuery.cpp:424: DB::parseQuery(DB::IParser&, char const*, char const*, String const&, unsigned long, unsigned long, unsigned long) @ 0x0000000017a96bbe 5. /build/src/Interpreters/executeQuery.cpp:955: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c8533e 6. /build/src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x0000000014c8ca7b 7. /build/src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000001686da12 8. /build/src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x0000000016870807 9. /build/src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x0000000016907e99 10. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 11. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 12. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 13. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 14. ? @ 0x00007fbc6213eac3 15. ? @ 0x00007fbc621d0850 2025.07.28 11:51:16.141210 [ 7630 ] {d1345b61-5314-409c-bfe3-0707530dd2cf} DynamicQueryHandler: Code: 62. DB::Exception: Max query size exceeded (can be increased with the `max_query_size` setting): Syntax error: failed at position 1048577 (-): -. . (SYNTAX_ERROR), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:111: DB::Exception::createDeprecated(String const&, int, bool) @ 0x000000000a08e96d 3. /build/src/Parsers/parseQuery.cpp:411: DB::parseQueryAndMovePosition(DB::IParser&, char const*&, char const*, String const&, bool, unsigned long, unsigned long, unsigned long) @ 0x0000000017a96b2c 4. /build/src/Parsers/parseQuery.cpp:424: DB::parseQuery(DB::IParser&, char const*, char const*, String const&, unsigned long, unsigned long, unsigned long) @ 0x0000000017a96bbe 5. /build/src/Interpreters/executeQuery.cpp:955: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c8533e 6. /build/src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x0000000014c8ca7b 7. /build/src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000001686da12 8. /build/src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x0000000016870807 9. /build/src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x0000000016907e99 10. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 11. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 12. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 13. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 14. ? @ 0x00007fbc6213eac3 15. ? @ 0x00007fbc621d0850 (version 25.3.6.10636.altinitytest (altinity build)) 2025.07.28 11:51:16.213316 [ 4474 ] {} 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. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x000000000c25bc4b 4. /build/src/Access/SettingsConstraints.cpp:343: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000138596e3 5. /build/src/Access/SettingsConstraints.cpp:300: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000013858faf 6. /build/src/Access/SettingsConstraints.cpp:209: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x00000000138592b8 7. /build/src/Interpreters/Context.cpp:2690: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000014436134 8. /build/src/Interpreters/Context.cpp:2729: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x000000001443662b 9. /build/src/Server/TCPHandler.cpp:2158: DB::TCPHandler::processQuery(std::optional&) @ 0x00000000168f61df 10. /build/src/Server/TCPHandler.cpp:918: DB::TCPHandler::receivePacketsExpectQuery(std::optional&) @ 0x00000000168ef965 11. /build/src/Server/TCPHandler.cpp:491: DB::TCPHandler::runImpl() @ 0x00000000168e5eb4 12. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 13. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 14. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 16. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 17. ? @ 0x00007fbc6213eac3 18. ? @ 0x00007fbc621d0850 2025.07.28 11:51:16.215626 [ 4474 ] {} 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. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000000a074fcb 4. /build/src/Server/TCPHandler.cpp:897: DB::TCPHandler::receivePacketsExpectQuery(std::optional&) @ 0x00000000168efa89 5. /build/src/Server/TCPHandler.cpp:491: DB::TCPHandler::runImpl() @ 0x00000000168e5eb4 6. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 7. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 8. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 9. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 10. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 11. ? @ 0x00007fbc6213eac3 12. ? @ 0x00007fbc621d0850 2025.07.28 11:51:16.237733 [ 11826 ] {cf3833c6-8ebe-47e5-bf9a-e3af40949b84} executeQuery: Code: 407. DB::Exception: Convert overflow: In scope SELECT toDecimal64('4294967296', 4) AS x, toUInt32(x). (DECIMAL_OVERFLOW) (version 25.3.6.10636.altinitytest (altinity build)) (from [::1]:50820) (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. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000000a074fcb 4. /build/src/Core/DecimalFunctions.h:354: T0::FieldType DB::convertFromDecimal>, DB::DataTypeNumber>(T::FieldType const&, unsigned int) @ 0x0000000013c2e9de 5. /build/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*) @ 0x0000000012feb222 6. /build/src/Functions/FunctionsConversion.h:2467: 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&&) @ 0x0000000012f9ce24 7. /build/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 @ 0x0000000012fb122e 8. /build/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 @ 0x0000000012fb0a5a 9. /build/src/Functions/IFunction.h:437: DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000a069f2a 10. /build/src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000012d9965a 11. /build/src/Functions/IFunction.cpp:351: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d93b02 12. /build/src/Functions/IFunction.cpp:177: DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d93698 13. /build/src/Functions/IFunction.cpp:343: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d93aad 14. /build/src/Functions/IFunction.cpp:420: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d95059 15. /build/src/Functions/IFunction.cpp:498: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d95c72 16. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3567: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000014034494 17. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3838: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000014019a9e 18. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3980: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000014018e31 19. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:4304: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000014042fa7 20. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5605: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000014013749 21. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000140127f9 22. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000014011fce 23. /build/src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000001406ce8a 24. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000014973b42 25. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000001497268d 26. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000014974d24 27. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001492924b 28. /build/src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88641 29. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 30. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 31. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 2025.07.28 11:51:16.252424 [ 11826 ] {} 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. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000000a074fcb 4. /build/src/Core/DecimalFunctions.h:354: T0::FieldType DB::convertFromDecimal>, DB::DataTypeNumber>(T::FieldType const&, unsigned int) @ 0x0000000013c2e9de 5. /build/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*) @ 0x0000000012feb222 6. /build/src/Functions/FunctionsConversion.h:2467: 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&&) @ 0x0000000012f9ce24 7. /build/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 @ 0x0000000012fb122e 8. /build/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 @ 0x0000000012fb0a5a 9. /build/src/Functions/IFunction.h:437: DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000a069f2a 10. /build/src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000012d9965a 11. /build/src/Functions/IFunction.cpp:351: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d93b02 12. /build/src/Functions/IFunction.cpp:177: DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d93698 13. /build/src/Functions/IFunction.cpp:343: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d93aad 14. /build/src/Functions/IFunction.cpp:420: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d95059 15. /build/src/Functions/IFunction.cpp:498: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d95c72 16. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3567: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000014034494 17. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3838: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000014019a9e 18. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3980: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000014018e31 19. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:4304: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000014042fa7 20. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5605: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000014013749 21. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000140127f9 22. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000014011fce 23. /build/src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000001406ce8a 24. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000014973b42 25. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000001497268d 26. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000014974d24 27. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001492924b 28. /build/src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88641 29. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 30. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 31. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 2025.07.28 11:51:16.383545 [ 6322 ] {} 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. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x000000000c25bc4b 4. /build/src/Access/SettingsConstraints.cpp:343: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000138596e3 5. /build/src/Access/SettingsConstraints.cpp:300: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000013858faf 6. /build/src/Access/SettingsConstraints.cpp:209: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x00000000138592b8 7. /build/src/Interpreters/Context.cpp:2690: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000014436134 8. /build/src/Interpreters/Context.cpp:2729: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x000000001443662b 9. /build/src/Server/TCPHandler.cpp:2158: DB::TCPHandler::processQuery(std::optional&) @ 0x00000000168f61df 10. /build/src/Server/TCPHandler.cpp:918: DB::TCPHandler::receivePacketsExpectQuery(std::optional&) @ 0x00000000168ef965 11. /build/src/Server/TCPHandler.cpp:491: DB::TCPHandler::runImpl() @ 0x00000000168e5eb4 12. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 13. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 14. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 16. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 17. ? @ 0x00007fbc6213eac3 18. ? @ 0x00007fbc621d0850 2025.07.28 11:51:16.385817 [ 6322 ] {} 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. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000000a074fcb 4. /build/src/Server/TCPHandler.cpp:897: DB::TCPHandler::receivePacketsExpectQuery(std::optional&) @ 0x00000000168efa89 5. /build/src/Server/TCPHandler.cpp:491: DB::TCPHandler::runImpl() @ 0x00000000168e5eb4 6. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 7. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 8. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 9. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 10. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 11. ? @ 0x00007fbc6213eac3 12. ? @ 0x00007fbc621d0850 2025.07.28 11:51:16.406024 [ 7408 ] {884b3a60-45c6-4830-8caf-4b8ca58c9a87} InterpreterCheckQuery: Check query for table test_9.tp_1 (6084bb2c-7960-43f7-b13d-0f487ee1618d) 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.6.10636.altinitytest (altinity build)) 2025.07.28 11:51:16.541170 [ 3287 ] {} 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. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x000000000c25bc4b 4. /build/src/Access/SettingsConstraints.cpp:343: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000138596e3 5. /build/src/Access/SettingsConstraints.cpp:300: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000013858faf 6. /build/src/Access/SettingsConstraints.cpp:209: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x00000000138592b8 7. /build/src/Interpreters/Context.cpp:2690: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000014436134 8. /build/src/Interpreters/Context.cpp:2729: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x000000001443662b 9. /build/src/Server/TCPHandler.cpp:2158: DB::TCPHandler::processQuery(std::optional&) @ 0x00000000168f61df 10. /build/src/Server/TCPHandler.cpp:918: DB::TCPHandler::receivePacketsExpectQuery(std::optional&) @ 0x00000000168ef965 11. /build/src/Server/TCPHandler.cpp:491: DB::TCPHandler::runImpl() @ 0x00000000168e5eb4 12. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 13. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 14. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 16. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 17. ? @ 0x00007fbc6213eac3 18. ? @ 0x00007fbc621d0850 2025.07.28 11:51:16.552221 [ 3287 ] {} 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. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000000a074fcb 4. /build/src/Server/TCPHandler.cpp:897: DB::TCPHandler::receivePacketsExpectQuery(std::optional&) @ 0x00000000168efa89 5. /build/src/Server/TCPHandler.cpp:491: DB::TCPHandler::runImpl() @ 0x00000000168e5eb4 6. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 7. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 8. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 9. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 10. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 11. ? @ 0x00007fbc6213eac3 12. ? @ 0x00007fbc621d0850 2025.07.28 11:51:16.604790 [ 11826 ] {64e65672-5179-4e74-8bed-764b2705b95e} executeQuery: Code: 407. DB::Exception: Convert overflow: In scope SELECT toDecimal128('65536', 0) AS x, toUInt16(x). (DECIMAL_OVERFLOW) (version 25.3.6.10636.altinitytest (altinity build)) (from [::1]:50820) (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. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000000a074fcb 4. /build/src/Core/DecimalFunctions.h:354: void DB::DecimalUtils::convertToImpl>, void>(DB::Decimal> const&, unsigned int, unsigned short&) @ 0x0000000013c27bec 5. /build/src/DataTypes/DataTypesDecimal.cpp:217: T0::FieldType DB::convertFromDecimal>>, DB::DataTypeNumber>(T::FieldType const&, unsigned int) @ 0x0000000013c2e6ab 6. /build/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*) @ 0x0000000012fe2022 7. /build/src/Functions/FunctionsConversion.h:2467: 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&&) @ 0x0000000012f9bc84 8. /build/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 @ 0x0000000012faff0e 9. /build/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 @ 0x0000000012faf73a 10. /build/src/Functions/IFunction.h:437: DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000a069f2a 11. /build/src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000012d9965a 12. /build/src/Functions/IFunction.cpp:351: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d93b02 13. /build/src/Functions/IFunction.cpp:177: DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d93698 14. /build/src/Functions/IFunction.cpp:343: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d93aad 15. /build/src/Functions/IFunction.cpp:420: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d95059 16. /build/src/Functions/IFunction.cpp:498: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d95c72 17. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3567: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000014034494 18. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3838: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000014019a9e 19. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3980: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000014018e31 20. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:4304: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000014042fa7 21. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5605: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000014013749 22. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000140127f9 23. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000014011fce 24. /build/src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000001406ce8a 25. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000014973b42 26. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000001497268d 27. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000014974d24 28. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001492924b 29. /build/src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88641 30. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 31. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 2025.07.28 11:51:16.615093 [ 11826 ] {} 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. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000000a074fcb 4. /build/src/Core/DecimalFunctions.h:354: void DB::DecimalUtils::convertToImpl>, void>(DB::Decimal> const&, unsigned int, unsigned short&) @ 0x0000000013c27bec 5. /build/src/DataTypes/DataTypesDecimal.cpp:217: T0::FieldType DB::convertFromDecimal>>, DB::DataTypeNumber>(T::FieldType const&, unsigned int) @ 0x0000000013c2e6ab 6. /build/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*) @ 0x0000000012fe2022 7. /build/src/Functions/FunctionsConversion.h:2467: 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&&) @ 0x0000000012f9bc84 8. /build/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 @ 0x0000000012faff0e 9. /build/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 @ 0x0000000012faf73a 10. /build/src/Functions/IFunction.h:437: DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000a069f2a 11. /build/src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000012d9965a 12. /build/src/Functions/IFunction.cpp:351: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d93b02 13. /build/src/Functions/IFunction.cpp:177: DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d93698 14. /build/src/Functions/IFunction.cpp:343: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d93aad 15. /build/src/Functions/IFunction.cpp:420: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d95059 16. /build/src/Functions/IFunction.cpp:498: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d95c72 17. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3567: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000014034494 18. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3838: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000014019a9e 19. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3980: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000014018e31 20. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:4304: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000014042fa7 21. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5605: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000014013749 22. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000140127f9 23. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000014011fce 24. /build/src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000001406ce8a 25. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000014973b42 26. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000001497268d 27. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000014974d24 28. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001492924b 29. /build/src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88641 30. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 31. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 2025.07.28 11:51:16.851397 [ 3287 ] {} 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. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x000000000c25bc4b 4. /build/src/Access/SettingsConstraints.cpp:343: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000138596e3 5. /build/src/Access/SettingsConstraints.cpp:300: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000013858faf 6. /build/src/Access/SettingsConstraints.cpp:209: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x00000000138592b8 7. /build/src/Interpreters/Context.cpp:2690: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000014436134 8. /build/src/Interpreters/Context.cpp:2729: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x000000001443662b 9. /build/src/Server/TCPHandler.cpp:2158: DB::TCPHandler::processQuery(std::optional&) @ 0x00000000168f61df 10. /build/src/Server/TCPHandler.cpp:918: DB::TCPHandler::receivePacketsExpectQuery(std::optional&) @ 0x00000000168ef965 11. /build/src/Server/TCPHandler.cpp:491: DB::TCPHandler::runImpl() @ 0x00000000168e5eb4 12. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 13. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 14. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 16. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 17. ? @ 0x00007fbc6213eac3 18. ? @ 0x00007fbc621d0850 2025.07.28 11:51:16.854998 [ 3287 ] {} 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. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000000a074fcb 4. /build/src/Server/TCPHandler.cpp:897: DB::TCPHandler::receivePacketsExpectQuery(std::optional&) @ 0x00000000168efa89 5. /build/src/Server/TCPHandler.cpp:491: DB::TCPHandler::runImpl() @ 0x00000000168e5eb4 6. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 7. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 8. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 9. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 10. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 11. ? @ 0x00007fbc6213eac3 12. ? @ 0x00007fbc621d0850 2025.07.28 11:51:16.983607 [ 11826 ] {1a3b797d-7462-415d-8c69-bb64abdb1c3e} executeQuery: Code: 407. DB::Exception: Convert overflow: In scope SELECT toDecimal128('65536', 10) AS x, toUInt16(x). (DECIMAL_OVERFLOW) (version 25.3.6.10636.altinitytest (altinity build)) (from [::1]:50820) (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. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000000a074fcb 4. /build/src/Core/DecimalFunctions.h:354: void DB::DecimalUtils::convertToImpl>, void>(DB::Decimal> const&, unsigned int, unsigned short&) @ 0x0000000013c27bec 5. /build/src/DataTypes/DataTypesDecimal.cpp:217: T0::FieldType DB::convertFromDecimal>>, DB::DataTypeNumber>(T::FieldType const&, unsigned int) @ 0x0000000013c2e6ab 6. /build/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*) @ 0x0000000012fe2022 7. /build/src/Functions/FunctionsConversion.h:2467: 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&&) @ 0x0000000012f9bc84 8. /build/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 @ 0x0000000012faff0e 9. /build/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 @ 0x0000000012faf73a 10. /build/src/Functions/IFunction.h:437: DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000a069f2a 11. /build/src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000012d9965a 12. /build/src/Functions/IFunction.cpp:351: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d93b02 13. /build/src/Functions/IFunction.cpp:177: DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d93698 14. /build/src/Functions/IFunction.cpp:343: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d93aad 15. /build/src/Functions/IFunction.cpp:420: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d95059 16. /build/src/Functions/IFunction.cpp:498: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d95c72 17. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3567: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000014034494 18. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3838: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000014019a9e 19. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3980: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000014018e31 20. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:4304: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000014042fa7 21. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5605: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000014013749 22. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000140127f9 23. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000014011fce 24. /build/src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000001406ce8a 25. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000014973b42 26. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000001497268d 27. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000014974d24 28. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001492924b 29. /build/src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88641 30. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 31. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 2025.07.28 11:51:16.991702 [ 11826 ] {} 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. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000000a074fcb 4. /build/src/Core/DecimalFunctions.h:354: void DB::DecimalUtils::convertToImpl>, void>(DB::Decimal> const&, unsigned int, unsigned short&) @ 0x0000000013c27bec 5. /build/src/DataTypes/DataTypesDecimal.cpp:217: T0::FieldType DB::convertFromDecimal>>, DB::DataTypeNumber>(T::FieldType const&, unsigned int) @ 0x0000000013c2e6ab 6. /build/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*) @ 0x0000000012fe2022 7. /build/src/Functions/FunctionsConversion.h:2467: 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&&) @ 0x0000000012f9bc84 8. /build/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 @ 0x0000000012faff0e 9. /build/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 @ 0x0000000012faf73a 10. /build/src/Functions/IFunction.h:437: DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000a069f2a 11. /build/src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000012d9965a 12. /build/src/Functions/IFunction.cpp:351: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d93b02 13. /build/src/Functions/IFunction.cpp:177: DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d93698 14. /build/src/Functions/IFunction.cpp:343: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d93aad 15. /build/src/Functions/IFunction.cpp:420: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d95059 16. /build/src/Functions/IFunction.cpp:498: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d95c72 17. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3567: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000014034494 18. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3838: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000014019a9e 19. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3980: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000014018e31 20. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:4304: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000014042fa7 21. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5605: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000014013749 22. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000140127f9 23. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000014011fce 24. /build/src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000001406ce8a 25. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000014973b42 26. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000001497268d 27. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000014974d24 28. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001492924b 29. /build/src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88641 30. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 31. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 2025.07.28 11:51:17.212825 [ 12807 ] {c8b11571-4f98-4087-9d86-7549aea4d6c7} executeQuery: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=818, jobs=779). (CANNOT_SCHEDULE_TASK) (version 25.3.6.10636.altinitytest (altinity build)) (from [::1]:37464) (comment: 02404_lightweight_delete_vertical_merge.sql) (query 17, line 78) (in query: SELECT * FROM lwd_test ORDER BY id, value;), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000fccaeeb 4. /build/src/Common/ThreadPool.cpp:275: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000fccacb3 5. /build/src/Common/ThreadPool.cpp:323: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fcc4ffc 6. /build/src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000000fcc584d 7. /build/src/Common/ThreadPool.h:279: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x00000000169bf193 8. /build/src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x00000000169bf518 9. /build/src/Server/TCPHandler.cpp:1237: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x00000000168f1525 10. /build/src/Server/TCPHandler.cpp:678: DB::TCPHandler::runImpl() @ 0x00000000168e68e5 11. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 12. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 13. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 14. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 15. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 16. ? @ 0x00007fbc6213eac3 17. ? @ 0x00007fbc621d0850 2025.07.28 11:51:17.222779 [ 12807 ] {} TCPHandler: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=818, jobs=779). (CANNOT_SCHEDULE_TASK), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000fccaeeb 4. /build/src/Common/ThreadPool.cpp:275: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000fccacb3 5. /build/src/Common/ThreadPool.cpp:323: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fcc4ffc 6. /build/src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000000fcc584d 7. /build/src/Common/ThreadPool.h:279: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x00000000169bf193 8. /build/src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x00000000169bf518 9. /build/src/Server/TCPHandler.cpp:1237: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x00000000168f1525 10. /build/src/Server/TCPHandler.cpp:678: DB::TCPHandler::runImpl() @ 0x00000000168e68e5 11. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 12. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 13. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 14. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 15. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 16. ? @ 0x00007fbc6213eac3 17. ? @ 0x00007fbc621d0850 2025.07.28 11:51:17.324156 [ 11826 ] {61fe38bd-cf01-495b-9dbb-36f0c074a4e3} executeQuery: Code: 407. DB::Exception: Convert overflow: In scope SELECT toDecimal64('65536', 0) AS x, toUInt16(x). (DECIMAL_OVERFLOW) (version 25.3.6.10636.altinitytest (altinity build)) (from [::1]:50820) (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. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000000a074fcb 4. /build/src/Core/DecimalFunctions.h:354: T0::FieldType DB::convertFromDecimal>, DB::DataTypeNumber>(T::FieldType const&, unsigned int) @ 0x0000000013c2e664 5. /build/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*) @ 0x0000000012fe1c02 6. /build/src/Functions/FunctionsConversion.h:2467: 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&&) @ 0x0000000012f9c0a4 7. /build/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 @ 0x0000000012faff0e 8. /build/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 @ 0x0000000012faf73a 9. /build/src/Functions/IFunction.h:437: DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000a069f2a 10. /build/src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000012d9965a 11. /build/src/Functions/IFunction.cpp:351: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d93b02 12. /build/src/Functions/IFunction.cpp:177: DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d93698 13. /build/src/Functions/IFunction.cpp:343: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d93aad 14. /build/src/Functions/IFunction.cpp:420: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d95059 15. /build/src/Functions/IFunction.cpp:498: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d95c72 16. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3567: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000014034494 17. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3838: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000014019a9e 18. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3980: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000014018e31 19. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:4304: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000014042fa7 20. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5605: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000014013749 21. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000140127f9 22. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000014011fce 23. /build/src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000001406ce8a 24. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000014973b42 25. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000001497268d 26. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000014974d24 27. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001492924b 28. /build/src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88641 29. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 30. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 31. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 2025.07.28 11:51:17.345060 [ 11826 ] {} 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. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000000a074fcb 4. /build/src/Core/DecimalFunctions.h:354: T0::FieldType DB::convertFromDecimal>, DB::DataTypeNumber>(T::FieldType const&, unsigned int) @ 0x0000000013c2e664 5. /build/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*) @ 0x0000000012fe1c02 6. /build/src/Functions/FunctionsConversion.h:2467: 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&&) @ 0x0000000012f9c0a4 7. /build/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 @ 0x0000000012faff0e 8. /build/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 @ 0x0000000012faf73a 9. /build/src/Functions/IFunction.h:437: DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000a069f2a 10. /build/src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000012d9965a 11. /build/src/Functions/IFunction.cpp:351: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d93b02 12. /build/src/Functions/IFunction.cpp:177: DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d93698 13. /build/src/Functions/IFunction.cpp:343: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d93aad 14. /build/src/Functions/IFunction.cpp:420: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d95059 15. /build/src/Functions/IFunction.cpp:498: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d95c72 16. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3567: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000014034494 17. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3838: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000014019a9e 18. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3980: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000014018e31 19. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:4304: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000014042fa7 20. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5605: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000014013749 21. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000140127f9 22. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000014011fce 23. /build/src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000001406ce8a 24. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000014973b42 25. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000001497268d 26. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000014974d24 27. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001492924b 28. /build/src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88641 29. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 30. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 31. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 2025.07.28 11:51:17.570331 [ 11826 ] {f9da0c26-b4b6-4f10-917e-652802031653} executeQuery: Code: 407. DB::Exception: Convert overflow: In scope SELECT toDecimal64('65536', 4) AS x, toUInt16(x). (DECIMAL_OVERFLOW) (version 25.3.6.10636.altinitytest (altinity build)) (from [::1]:50820) (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. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000000a074fcb 4. /build/src/Core/DecimalFunctions.h:354: T0::FieldType DB::convertFromDecimal>, DB::DataTypeNumber>(T::FieldType const&, unsigned int) @ 0x0000000013c2e664 5. /build/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*) @ 0x0000000012fe1c02 6. /build/src/Functions/FunctionsConversion.h:2467: 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&&) @ 0x0000000012f9c0a4 7. /build/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 @ 0x0000000012faff0e 8. /build/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 @ 0x0000000012faf73a 9. /build/src/Functions/IFunction.h:437: DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000a069f2a 10. /build/src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000012d9965a 11. /build/src/Functions/IFunction.cpp:351: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d93b02 12. /build/src/Functions/IFunction.cpp:177: DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d93698 13. /build/src/Functions/IFunction.cpp:343: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d93aad 14. /build/src/Functions/IFunction.cpp:420: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d95059 15. /build/src/Functions/IFunction.cpp:498: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d95c72 16. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3567: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000014034494 17. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3838: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000014019a9e 18. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3980: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000014018e31 19. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:4304: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000014042fa7 20. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5605: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000014013749 21. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000140127f9 22. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000014011fce 23. /build/src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000001406ce8a 24. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000014973b42 25. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000001497268d 26. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000014974d24 27. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001492924b 28. /build/src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88641 29. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 30. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 31. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 2025.07.28 11:51:17.573366 [ 7625 ] {bedd5b48-1f69-4a7b-a046-634a1ff144bc} executeQuery: Code: 36. DB::Exception: Argument 'kafka_broker_list' must be a literal, get Function_equals (value: a = '1'). (BAD_ARGUMENTS) (version 25.3.6.10636.altinitytest (altinity build)) (from [::1]:37900) (comment: 03305_fix_kafka_table_with_kw_arguments.sql) (query 1, line 3) (in query: CREATE TABLE default.test ( `id` UInt32, `message` String ) ENGINE = Kafka(a = '1', 'clickhouse');), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, String&&, String&&) @ 0x000000001098ed2b 4. /build/src/Storages/checkAndGetLiteralArgument.cpp:25: String DB::checkAndGetLiteralArgument(std::shared_ptr const&, String const&) @ 0x0000000016051f87 5. /build/src/Storages/Kafka/StorageKafkaUtils.cpp:169: DB::registerStorageKafka(DB::StorageFactory&)::$_0::operator()(DB::StorageFactory::Arguments const&) const @ 0x000000001328b0b1 6. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000015d81ea2 7. /build/src/Interpreters/InterpreterCreateQuery.cpp:1945: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x00000000149009bb 8. /build/src/Interpreters/InterpreterCreateQuery.cpp:1743: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000148f9aa9 9. /build/src/Interpreters/InterpreterCreateQuery.cpp:2352: DB::InterpreterCreateQuery::execute() @ 0x0000000014905a41 10. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88dc9 11. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 12. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 13. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 14. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 15. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 16. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 17. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 18. ? @ 0x00007fbc6213eac3 19. ? @ 0x00007fbc621d0850 2025.07.28 11:51:17.576442 [ 7625 ] {} TCPHandler: Code: 36. DB::Exception: Argument 'kafka_broker_list' must be a literal, get Function_equals (value: a = '1'). (BAD_ARGUMENTS), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, String&&, String&&) @ 0x000000001098ed2b 4. /build/src/Storages/checkAndGetLiteralArgument.cpp:25: String DB::checkAndGetLiteralArgument(std::shared_ptr const&, String const&) @ 0x0000000016051f87 5. /build/src/Storages/Kafka/StorageKafkaUtils.cpp:169: DB::registerStorageKafka(DB::StorageFactory&)::$_0::operator()(DB::StorageFactory::Arguments const&) const @ 0x000000001328b0b1 6. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000015d81ea2 7. /build/src/Interpreters/InterpreterCreateQuery.cpp:1945: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x00000000149009bb 8. /build/src/Interpreters/InterpreterCreateQuery.cpp:1743: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000148f9aa9 9. /build/src/Interpreters/InterpreterCreateQuery.cpp:2352: DB::InterpreterCreateQuery::execute() @ 0x0000000014905a41 10. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88dc9 11. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 12. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 13. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 14. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 15. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 16. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 17. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 18. ? @ 0x00007fbc6213eac3 19. ? @ 0x00007fbc621d0850 2025.07.28 11:51:17.583885 [ 11826 ] {} 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. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000000a074fcb 4. /build/src/Core/DecimalFunctions.h:354: T0::FieldType DB::convertFromDecimal>, DB::DataTypeNumber>(T::FieldType const&, unsigned int) @ 0x0000000013c2e664 5. /build/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*) @ 0x0000000012fe1c02 6. /build/src/Functions/FunctionsConversion.h:2467: 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&&) @ 0x0000000012f9c0a4 7. /build/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 @ 0x0000000012faff0e 8. /build/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 @ 0x0000000012faf73a 9. /build/src/Functions/IFunction.h:437: DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000a069f2a 10. /build/src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000012d9965a 11. /build/src/Functions/IFunction.cpp:351: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d93b02 12. /build/src/Functions/IFunction.cpp:177: DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d93698 13. /build/src/Functions/IFunction.cpp:343: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d93aad 14. /build/src/Functions/IFunction.cpp:420: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d95059 15. /build/src/Functions/IFunction.cpp:498: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d95c72 16. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3567: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000014034494 17. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3838: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000014019a9e 18. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3980: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000014018e31 19. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:4304: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000014042fa7 20. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5605: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000014013749 21. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000140127f9 22. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000014011fce 23. /build/src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000001406ce8a 24. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000014973b42 25. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000001497268d 26. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000014974d24 27. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001492924b 28. /build/src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88641 29. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 30. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 31. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 2025.07.28 11:51:18.291192 [ 11826 ] {7cb44e14-69b3-491b-83f5-07e05b6aa5f8} 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.6.10636.altinitytest (altinity build)) (from [::1]:50820) (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. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/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&&) @ 0x000000000a1011eb 4. /build/src/DataTypes/DataTypesDecimal.cpp:155: void DB::convertDecimalsImpl>, DB::DataTypeDecimal>, void>(T::FieldType const&, unsigned int, unsigned int, T0::FieldType&) @ 0x0000000013c1e6d8 5. /build/src/DataTypes/DataTypesDecimal.cpp:308: T0::FieldType DB::convertToDecimal, DB::DataTypeDecimal>>(T::FieldType const&, unsigned int) @ 0x0000000013c32adf 6. /build/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) @ 0x0000000013108394 7. /build/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 @ 0x00000000130fdc04 8. /build/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&&) @ 0x0000000012fad2b1 9. /build/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 @ 0x0000000012fce44e 10. /build/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 @ 0x0000000012fcdc7a 11. /build/src/Functions/IFunction.h:437: DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000a069f2a 12. /build/src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000012d9965a 13. /build/src/Functions/IFunction.cpp:351: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d93b02 14. /build/src/Functions/IFunction.cpp:177: DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d93698 15. /build/src/Functions/IFunction.cpp:343: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d93aad 16. /build/src/Functions/IFunction.cpp:420: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d95059 17. /build/src/Functions/IFunction.cpp:498: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d95c72 18. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3567: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000014034494 19. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3838: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000014019a9e 20. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3980: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000014018e31 21. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:4304: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000014042fa7 22. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5605: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000014013749 23. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000140127f9 24. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000014011fce 25. /build/src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000001406ce8a 26. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000014973b42 27. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000001497268d 28. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000014974d24 29. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001492924b 30. /build/src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88641 31. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 2025.07.28 11:51:18.295749 [ 11826 ] {} 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. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/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&&) @ 0x000000000a1011eb 4. /build/src/DataTypes/DataTypesDecimal.cpp:155: void DB::convertDecimalsImpl>, DB::DataTypeDecimal>, void>(T::FieldType const&, unsigned int, unsigned int, T0::FieldType&) @ 0x0000000013c1e6d8 5. /build/src/DataTypes/DataTypesDecimal.cpp:308: T0::FieldType DB::convertToDecimal, DB::DataTypeDecimal>>(T::FieldType const&, unsigned int) @ 0x0000000013c32adf 6. /build/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) @ 0x0000000013108394 7. /build/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 @ 0x00000000130fdc04 8. /build/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&&) @ 0x0000000012fad2b1 9. /build/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 @ 0x0000000012fce44e 10. /build/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 @ 0x0000000012fcdc7a 11. /build/src/Functions/IFunction.h:437: DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000a069f2a 12. /build/src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000012d9965a 13. /build/src/Functions/IFunction.cpp:351: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d93b02 14. /build/src/Functions/IFunction.cpp:177: DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d93698 15. /build/src/Functions/IFunction.cpp:343: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d93aad 16. /build/src/Functions/IFunction.cpp:420: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d95059 17. /build/src/Functions/IFunction.cpp:498: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d95c72 18. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3567: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000014034494 19. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3838: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000014019a9e 20. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3980: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000014018e31 21. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:4304: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000014042fa7 22. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5605: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000014013749 23. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000140127f9 24. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000014011fce 25. /build/src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000001406ce8a 26. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000014973b42 27. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000001497268d 28. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000014974d24 29. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001492924b 30. /build/src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88641 31. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 2025.07.28 11:51:18.302445 [ 5327 ] {a78bcf48-c8b8-41f8-8e53-84a10f96b69f} executeQuery: Code: 62. DB::Exception: Cannot TRUNCATE dictionary. (SYNTAX_ERROR) (version 25.3.6.10636.altinitytest (altinity build)) (from [::1]:37556) (comment: 02185_range_hashed_dictionary_open_ranges.sql) (query 26, line 63) (in query: DROP DICTIONARY 02185_range_dictionary;), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000000a074fcb 4. /build/src/Interpreters/InterpreterDropQuery.cpp:266: DB::InterpreterDropQuery::executeToTableImpl(std::shared_ptr const&, DB::ASTDropQuery&, std::shared_ptr&, StrongTypedef, DB::UUIDTag>&) @ 0x0000000014915b7b 5. /build/src/Interpreters/InterpreterDropQuery.cpp:118: DB::InterpreterDropQuery::executeToTable(DB::ASTDropQuery&) @ 0x00000000149137b4 6. /build/src/Interpreters/InterpreterDropQuery.cpp:91: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000014912f07 7. /build/src/Interpreters/InterpreterDropQuery.cpp:72: DB::InterpreterDropQuery::execute() @ 0x0000000014912b65 8. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88dc9 9. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 10. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 11. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 12. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 13. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 14. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 15. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 16. ? @ 0x00007fbc6213eac3 17. ? @ 0x00007fbc621d0850 2025.07.28 11:51:18.316099 [ 5327 ] {} TCPHandler: Code: 62. DB::Exception: Cannot TRUNCATE dictionary. (SYNTAX_ERROR), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000000a074fcb 4. /build/src/Interpreters/InterpreterDropQuery.cpp:266: DB::InterpreterDropQuery::executeToTableImpl(std::shared_ptr const&, DB::ASTDropQuery&, std::shared_ptr&, StrongTypedef, DB::UUIDTag>&) @ 0x0000000014915b7b 5. /build/src/Interpreters/InterpreterDropQuery.cpp:118: DB::InterpreterDropQuery::executeToTable(DB::ASTDropQuery&) @ 0x00000000149137b4 6. /build/src/Interpreters/InterpreterDropQuery.cpp:91: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000014912f07 7. /build/src/Interpreters/InterpreterDropQuery.cpp:72: DB::InterpreterDropQuery::execute() @ 0x0000000014912b65 8. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88dc9 9. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 10. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 11. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 12. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 13. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 14. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 15. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 16. ? @ 0x00007fbc6213eac3 17. ? @ 0x00007fbc621d0850 2025.07.28 11:51:18.465976 [ 11826 ] {9540e61e-01de-4bdf-b08a-a10325895fc0} 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.6.10636.altinitytest (altinity build)) (from [::1]:50820) (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. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/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&&) @ 0x000000000a1011eb 4. /build/src/DataTypes/DataTypesDecimal.cpp:155: void DB::convertDecimalsImpl>, DB::DataTypeDecimal>, void>(T::FieldType const&, unsigned int, unsigned int, T0::FieldType&) @ 0x0000000013c1e6d8 5. /build/src/DataTypes/DataTypesDecimal.cpp:308: T0::FieldType DB::convertToDecimal, DB::DataTypeDecimal>>(T::FieldType const&, unsigned int) @ 0x0000000013c32adf 6. /build/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) @ 0x0000000013108394 7. /build/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 @ 0x00000000130fdc04 8. /build/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&&) @ 0x0000000012fad2b1 9. /build/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 @ 0x0000000012fce44e 10. /build/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 @ 0x0000000012fcdc7a 11. /build/src/Functions/IFunction.h:437: DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000a069f2a 12. /build/src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000012d9965a 13. /build/src/Functions/IFunction.cpp:351: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d93b02 14. /build/src/Functions/IFunction.cpp:177: DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d93698 15. /build/src/Functions/IFunction.cpp:343: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d93aad 16. /build/src/Functions/IFunction.cpp:420: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d95059 17. /build/src/Functions/IFunction.cpp:498: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d95c72 18. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3567: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000014034494 19. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3838: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000014019a9e 20. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3980: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000014018e31 21. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:4304: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000014042fa7 22. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5605: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000014013749 23. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000140127f9 24. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000014011fce 25. /build/src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000001406ce8a 26. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000014973b42 27. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000001497268d 28. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000014974d24 29. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001492924b 30. /build/src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88641 31. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 2025.07.28 11:51:18.470579 [ 11826 ] {} 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. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/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&&) @ 0x000000000a1011eb 4. /build/src/DataTypes/DataTypesDecimal.cpp:155: void DB::convertDecimalsImpl>, DB::DataTypeDecimal>, void>(T::FieldType const&, unsigned int, unsigned int, T0::FieldType&) @ 0x0000000013c1e6d8 5. /build/src/DataTypes/DataTypesDecimal.cpp:308: T0::FieldType DB::convertToDecimal, DB::DataTypeDecimal>>(T::FieldType const&, unsigned int) @ 0x0000000013c32adf 6. /build/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) @ 0x0000000013108394 7. /build/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 @ 0x00000000130fdc04 8. /build/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&&) @ 0x0000000012fad2b1 9. /build/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 @ 0x0000000012fce44e 10. /build/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 @ 0x0000000012fcdc7a 11. /build/src/Functions/IFunction.h:437: DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000a069f2a 12. /build/src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000012d9965a 13. /build/src/Functions/IFunction.cpp:351: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d93b02 14. /build/src/Functions/IFunction.cpp:177: DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d93698 15. /build/src/Functions/IFunction.cpp:343: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d93aad 16. /build/src/Functions/IFunction.cpp:420: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d95059 17. /build/src/Functions/IFunction.cpp:498: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d95c72 18. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3567: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000014034494 19. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3838: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000014019a9e 20. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3980: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000014018e31 21. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:4304: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000014042fa7 22. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5605: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000014013749 23. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000140127f9 24. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000014011fce 25. /build/src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000001406ce8a 26. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000014973b42 27. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000001497268d 28. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000014974d24 29. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001492924b 30. /build/src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88641 31. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 2025.07.28 11:51:18.691473 [ 11826 ] {884c0636-645e-47f6-8513-ad62384d773c} 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.6.10636.altinitytest (altinity build)) (from [::1]:50820) (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. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/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&&) @ 0x000000000a1011eb 4. /build/src/DataTypes/DataTypesDecimal.cpp:155: void DB::convertDecimalsImpl>>, DB::DataTypeDecimal>, void>(T::FieldType const&, unsigned int, unsigned int, T0::FieldType&) @ 0x0000000013c1ea8e 5. /build/src/DataTypes/DataTypesDecimal.cpp:306: T0::FieldType DB::convertToDecimal, DB::DataTypeDecimal>>(T::FieldType const&, unsigned int) @ 0x0000000013c32b28 6. /build/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) @ 0x0000000013103b94 7. /build/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 @ 0x00000000130fcd04 8. /build/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&&) @ 0x0000000012fad281 9. /build/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 @ 0x0000000012fce44e 10. /build/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 @ 0x0000000012fcdc7a 11. /build/src/Functions/IFunction.h:437: DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000a069f2a 12. /build/src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000012d9965a 13. /build/src/Functions/IFunction.cpp:351: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d93b02 14. /build/src/Functions/IFunction.cpp:177: DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d93698 15. /build/src/Functions/IFunction.cpp:343: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d93aad 16. /build/src/Functions/IFunction.cpp:420: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d95059 17. /build/src/Functions/IFunction.cpp:498: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d95c72 18. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3567: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000014034494 19. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3838: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000014019a9e 20. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3980: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000014018e31 21. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:4304: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000014042fa7 22. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5605: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000014013749 23. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000140127f9 24. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000014011fce 25. /build/src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000001406ce8a 26. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000014973b42 27. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000001497268d 28. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000014974d24 29. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001492924b 30. /build/src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88641 31. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 2025.07.28 11:51:18.694803 [ 11826 ] {} 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. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/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&&) @ 0x000000000a1011eb 4. /build/src/DataTypes/DataTypesDecimal.cpp:155: void DB::convertDecimalsImpl>>, DB::DataTypeDecimal>, void>(T::FieldType const&, unsigned int, unsigned int, T0::FieldType&) @ 0x0000000013c1ea8e 5. /build/src/DataTypes/DataTypesDecimal.cpp:306: T0::FieldType DB::convertToDecimal, DB::DataTypeDecimal>>(T::FieldType const&, unsigned int) @ 0x0000000013c32b28 6. /build/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) @ 0x0000000013103b94 7. /build/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 @ 0x00000000130fcd04 8. /build/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&&) @ 0x0000000012fad281 9. /build/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 @ 0x0000000012fce44e 10. /build/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 @ 0x0000000012fcdc7a 11. /build/src/Functions/IFunction.h:437: DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000a069f2a 12. /build/src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000012d9965a 13. /build/src/Functions/IFunction.cpp:351: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d93b02 14. /build/src/Functions/IFunction.cpp:177: DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d93698 15. /build/src/Functions/IFunction.cpp:343: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d93aad 16. /build/src/Functions/IFunction.cpp:420: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d95059 17. /build/src/Functions/IFunction.cpp:498: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d95c72 18. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3567: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000014034494 19. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3838: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000014019a9e 20. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3980: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000014018e31 21. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:4304: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000014042fa7 22. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5605: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000014013749 23. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000140127f9 24. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000014011fce 25. /build/src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000001406ce8a 26. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000014973b42 27. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000001497268d 28. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000014974d24 29. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001492924b 30. /build/src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88641 31. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 2025.07.28 11:51:19.110411 [ 11826 ] {0f18eebb-0dea-4a2c-bd11-1e841d3a7993} 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.6.10636.altinitytest (altinity build)) (from [::1]:50820) (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. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/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&&) @ 0x000000000a1011eb 4. /build/src/DataTypes/DataTypesDecimal.cpp:155: void DB::convertDecimalsImpl>>, DB::DataTypeDecimal>, void>(T::FieldType const&, unsigned int, unsigned int, T0::FieldType&) @ 0x0000000013c207d0 5. /build/src/DataTypes/DataTypesDecimal.cpp:306: T0::FieldType DB::convertToDecimal, DB::DataTypeDecimal>>(T::FieldType const&, unsigned int) @ 0x0000000013c32f86 6. /build/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) @ 0x000000001311c2b5 7. /build/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 @ 0x0000000013115424 8. /build/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&&) @ 0x0000000012fad581 9. /build/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 @ 0x0000000012fcf80e 10. /build/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 @ 0x0000000012fcf03a 11. /build/src/Functions/IFunction.h:437: DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000a069f2a 12. /build/src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000012d9965a 13. /build/src/Functions/IFunction.cpp:351: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d93b02 14. /build/src/Functions/IFunction.cpp:177: DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d93698 15. /build/src/Functions/IFunction.cpp:343: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d93aad 16. /build/src/Functions/IFunction.cpp:420: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d95059 17. /build/src/Functions/IFunction.cpp:498: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d95c72 18. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3567: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000014034494 19. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3838: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000014019a9e 20. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3980: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000014018e31 21. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:4304: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000014042fa7 22. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5605: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000014013749 23. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000140127f9 24. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000014011fce 25. /build/src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000001406ce8a 26. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000014973b42 27. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000001497268d 28. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000014974d24 29. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001492924b 30. /build/src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88641 31. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 2025.07.28 11:51:19.126745 [ 11826 ] {} 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. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/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&&) @ 0x000000000a1011eb 4. /build/src/DataTypes/DataTypesDecimal.cpp:155: void DB::convertDecimalsImpl>>, DB::DataTypeDecimal>, void>(T::FieldType const&, unsigned int, unsigned int, T0::FieldType&) @ 0x0000000013c207d0 5. /build/src/DataTypes/DataTypesDecimal.cpp:306: T0::FieldType DB::convertToDecimal, DB::DataTypeDecimal>>(T::FieldType const&, unsigned int) @ 0x0000000013c32f86 6. /build/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) @ 0x000000001311c2b5 7. /build/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 @ 0x0000000013115424 8. /build/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&&) @ 0x0000000012fad581 9. /build/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 @ 0x0000000012fcf80e 10. /build/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 @ 0x0000000012fcf03a 11. /build/src/Functions/IFunction.h:437: DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000a069f2a 12. /build/src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000012d9965a 13. /build/src/Functions/IFunction.cpp:351: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d93b02 14. /build/src/Functions/IFunction.cpp:177: DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d93698 15. /build/src/Functions/IFunction.cpp:343: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d93aad 16. /build/src/Functions/IFunction.cpp:420: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d95059 17. /build/src/Functions/IFunction.cpp:498: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d95c72 18. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3567: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000014034494 19. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3838: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000014019a9e 20. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3980: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000014018e31 21. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:4304: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000014042fa7 22. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5605: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000014013749 23. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000140127f9 24. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000014011fce 25. /build/src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000001406ce8a 26. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000014973b42 27. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000001497268d 28. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000014974d24 29. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001492924b 30. /build/src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88641 31. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 2025.07.28 11:51:19.392613 [ 11826 ] {be776270-d98f-4fa0-bb0b-ec6153e20a9c} 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.6.10636.altinitytest (altinity build)) (from [::1]:50820) (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. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: 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&&) @ 0x0000000012da74d9 4. /build/src/Functions/FunctionHelpers.cpp:130: DB::(anonymous namespace)::validateArgumentsImpl(DB::IFunction const&, std::vector> const&, unsigned long, std::vector> const&) @ 0x0000000012da5b15 5. /build/src/Functions/FunctionHelpers.cpp:192: DB::validateFunctionArguments(DB::IFunction const&, std::vector> const&, std::vector> const&, std::vector> const&) @ 0x0000000012da54fb 6. /build/src/Functions/FunctionsConversion.h:2234: DB::detail::FunctionConvert>, DB::detail::NameToDecimal32, DB::detail::UnknownMonotonicity>::getReturnTypeImplRemovedNullable(std::vector> const&) const @ 0x0000000012fcda79 7. /build/src/Functions/FunctionsConversion.h:2197: DB::detail::FunctionConvert>, DB::detail::NameToDecimal32, DB::detail::UnknownMonotonicity>::getReturnTypeImpl(std::vector> const&) const @ 0x0000000012fcd915 8. /build/src/Functions/IFunction.cpp:645: DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x0000000012d96b0c 9. /build/src/Functions/IFunction.cpp:577: DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x0000000012d9669c 10. /build/src/Functions/IFunction.cpp:606: DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x0000000012d96edc 11. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3544: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000014033cc9 12. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3838: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000014019a9e 13. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3980: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000014018e31 14. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:4304: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000014042fa7 15. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5605: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000014013749 16. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000140127f9 17. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000014011fce 18. /build/src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000001406ce8a 19. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000014973b42 20. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000001497268d 21. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000014974d24 22. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001492924b 23. /build/src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88641 24. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 25. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 26. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 27. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 28. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 29. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 30. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 31. ? @ 0x00007fbc6213eac3 2025.07.28 11:51:19.391406 [ 4900 ] {64b9f231-62b1-42c9-b88e-37cb0924aeae} executeQuery: Code: 47. DB::Exception: Missing columns: 'All' while processing: '`All`', required columns: 'All', available columns: 'id'. (UNKNOWN_IDENTIFIER) (version 25.3.6.10636.altinitytest (altinity build)) (from [::1]:37994) (comment: 03316_fixup_used_columns_exception.sh) (query 1, line 2) (in query: CREATE TABLE test_exception (`id` UInt64) ENGINE = MergeTree ORDER BY `All` SETTINGS index_granularity = 30917, 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 = 393185689, compact_parts_max_bytes_to_buffer = 212752421, compact_parts_max_granules_to_buffer = 32, compact_parts_merge_max_bytes_to_prefetch_part = 24522345, merge_max_block_size = 4578, old_parts_lifetime = 444., prefer_fetch_merged_part_size_threshold = 1, vertical_merge_algorithm_min_rows_to_activate = 683458, vertical_merge_algorithm_min_columns_to_activate = 1, min_merge_bytes_to_use_direct_io = 7203732178, index_granularity_bytes = 2009859, 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 = false, cache_populated_by_fetch = false, marks_compress_block_size = 21984, primary_key_compress_block_size = 42216, 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. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Interpreters/TreeRewriter.cpp:1303: DB::TreeRewriterResult::collectUsedColumns(std::shared_ptr const&, bool, bool) @ 0x0000000014c01fc8 4. /build/src/Interpreters/TreeRewriter.cpp:1561: DB::TreeRewriter::analyze(std::shared_ptr&, DB::NamesAndTypesList const&, std::shared_ptr, std::shared_ptr const&, bool, bool, bool, bool) const @ 0x0000000014c0a438 5. /build/src/Storages/KeyDescription.cpp:163: DB::KeyDescription::getSortingKeyFromAST(std::shared_ptr const&, DB::ColumnsDescription const&, std::shared_ptr, std::optional const&) @ 0x0000000015d2e395 6. /build/src/Storages/MergeTree/registerStorageMergeTree.cpp:668: DB::create(DB::StorageFactory::Arguments const&) @ 0x000000001662daa0 7. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000015d81ea2 8. /build/src/Interpreters/InterpreterCreateQuery.cpp:1945: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x00000000149009bb 9. /build/src/Interpreters/InterpreterCreateQuery.cpp:1743: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000148f9aa9 10. /build/src/Interpreters/InterpreterCreateQuery.cpp:2352: DB::InterpreterCreateQuery::execute() @ 0x0000000014905a41 11. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88dc9 12. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 13. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 14. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 15. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 16. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 17. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 18. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 19. ? @ 0x00007fbc6213eac3 20. ? @ 0x00007fbc621d0850 2025.07.28 11:51:19.404242 [ 11826 ] {} 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. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: 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&&) @ 0x0000000012da74d9 4. /build/src/Functions/FunctionHelpers.cpp:130: DB::(anonymous namespace)::validateArgumentsImpl(DB::IFunction const&, std::vector> const&, unsigned long, std::vector> const&) @ 0x0000000012da5b15 5. /build/src/Functions/FunctionHelpers.cpp:192: DB::validateFunctionArguments(DB::IFunction const&, std::vector> const&, std::vector> const&, std::vector> const&) @ 0x0000000012da54fb 6. /build/src/Functions/FunctionsConversion.h:2234: DB::detail::FunctionConvert>, DB::detail::NameToDecimal32, DB::detail::UnknownMonotonicity>::getReturnTypeImplRemovedNullable(std::vector> const&) const @ 0x0000000012fcda79 7. /build/src/Functions/FunctionsConversion.h:2197: DB::detail::FunctionConvert>, DB::detail::NameToDecimal32, DB::detail::UnknownMonotonicity>::getReturnTypeImpl(std::vector> const&) const @ 0x0000000012fcd915 8. /build/src/Functions/IFunction.cpp:645: DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x0000000012d96b0c 9. /build/src/Functions/IFunction.cpp:577: DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x0000000012d9669c 10. /build/src/Functions/IFunction.cpp:606: DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x0000000012d96edc 11. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3544: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000014033cc9 12. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3838: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000014019a9e 13. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3980: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000014018e31 14. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:4304: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000014042fa7 15. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5605: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000014013749 16. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000140127f9 17. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000014011fce 18. /build/src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000001406ce8a 19. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000014973b42 20. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000001497268d 21. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000014974d24 22. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001492924b 23. /build/src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88641 24. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 25. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 26. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 27. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 28. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 29. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 30. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 31. ? @ 0x00007fbc6213eac3 2025.07.28 11:51:19.414752 [ 4581 ] {} 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. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x000000000c25bc4b 4. /build/src/Access/SettingsConstraints.cpp:343: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000138596e3 5. /build/src/Access/SettingsConstraints.cpp:300: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000013858faf 6. /build/src/Access/SettingsConstraints.cpp:209: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x00000000138592b8 7. /build/src/Interpreters/Context.cpp:2690: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000014436134 8. /build/src/Interpreters/Context.cpp:2729: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x000000001443662b 9. /build/src/Server/TCPHandler.cpp:2158: DB::TCPHandler::processQuery(std::optional&) @ 0x00000000168f61df 10. /build/src/Server/TCPHandler.cpp:918: DB::TCPHandler::receivePacketsExpectQuery(std::optional&) @ 0x00000000168ef965 11. /build/src/Server/TCPHandler.cpp:491: DB::TCPHandler::runImpl() @ 0x00000000168e5eb4 12. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 13. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 14. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 16. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 17. ? @ 0x00007fbc6213eac3 18. ? @ 0x00007fbc621d0850 2025.07.28 11:51:19.416650 [ 4581 ] {} 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. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000000a074fcb 4. /build/src/Server/TCPHandler.cpp:897: DB::TCPHandler::receivePacketsExpectQuery(std::optional&) @ 0x00000000168efa89 5. /build/src/Server/TCPHandler.cpp:491: DB::TCPHandler::runImpl() @ 0x00000000168e5eb4 6. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 7. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 8. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 9. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 10. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 11. ? @ 0x00007fbc6213eac3 12. ? @ 0x00007fbc621d0850 2025.07.28 11:51:19.439782 [ 4900 ] {} TCPHandler: Code: 47. DB::Exception: Missing columns: 'All' while processing: '`All`', required columns: 'All', available columns: 'id'. (UNKNOWN_IDENTIFIER), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Interpreters/TreeRewriter.cpp:1303: DB::TreeRewriterResult::collectUsedColumns(std::shared_ptr const&, bool, bool) @ 0x0000000014c01fc8 4. /build/src/Interpreters/TreeRewriter.cpp:1561: DB::TreeRewriter::analyze(std::shared_ptr&, DB::NamesAndTypesList const&, std::shared_ptr, std::shared_ptr const&, bool, bool, bool, bool) const @ 0x0000000014c0a438 5. /build/src/Storages/KeyDescription.cpp:163: DB::KeyDescription::getSortingKeyFromAST(std::shared_ptr const&, DB::ColumnsDescription const&, std::shared_ptr, std::optional const&) @ 0x0000000015d2e395 6. /build/src/Storages/MergeTree/registerStorageMergeTree.cpp:668: DB::create(DB::StorageFactory::Arguments const&) @ 0x000000001662daa0 7. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000015d81ea2 8. /build/src/Interpreters/InterpreterCreateQuery.cpp:1945: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x00000000149009bb 9. /build/src/Interpreters/InterpreterCreateQuery.cpp:1743: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000148f9aa9 10. /build/src/Interpreters/InterpreterCreateQuery.cpp:2352: DB::InterpreterCreateQuery::execute() @ 0x0000000014905a41 11. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88dc9 12. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 13. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 14. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 15. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 16. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 17. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 18. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 19. ? @ 0x00007fbc6213eac3 20. ? @ 0x00007fbc621d0850 2025.07.28 11:51:19.573056 [ 11826 ] {a24512dd-0c78-42da-b7be-dfebfe138218} 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.6.10636.altinitytest (altinity build)) (from [::1]:50820) (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. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: 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&&) @ 0x0000000012da74d9 4. /build/src/Functions/FunctionHelpers.cpp:130: DB::(anonymous namespace)::validateArgumentsImpl(DB::IFunction const&, std::vector> const&, unsigned long, std::vector> const&) @ 0x0000000012da5b15 5. /build/src/Functions/FunctionHelpers.cpp:192: DB::validateFunctionArguments(DB::IFunction const&, std::vector> const&, std::vector> const&, std::vector> const&) @ 0x0000000012da54fb 6. /build/src/Functions/FunctionsConversion.h:2234: DB::detail::FunctionConvert>, DB::detail::NameToDecimal64, DB::detail::UnknownMonotonicity>::getReturnTypeImplRemovedNullable(std::vector> const&) const @ 0x0000000012fcee39 7. /build/src/Functions/FunctionsConversion.h:2197: DB::detail::FunctionConvert>, DB::detail::NameToDecimal64, DB::detail::UnknownMonotonicity>::getReturnTypeImpl(std::vector> const&) const @ 0x0000000012fcecd5 8. /build/src/Functions/IFunction.cpp:645: DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x0000000012d96b0c 9. /build/src/Functions/IFunction.cpp:577: DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x0000000012d9669c 10. /build/src/Functions/IFunction.cpp:606: DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x0000000012d96edc 11. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3544: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000014033cc9 12. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3838: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000014019a9e 13. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3980: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000014018e31 14. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:4304: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000014042fa7 15. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5605: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000014013749 16. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000140127f9 17. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000014011fce 18. /build/src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000001406ce8a 19. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000014973b42 20. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000001497268d 21. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000014974d24 22. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001492924b 23. /build/src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88641 24. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 25. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 26. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 27. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 28. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 29. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 30. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 31. ? @ 0x00007fbc6213eac3 2025.07.28 11:51:19.583117 [ 11826 ] {} 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. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: 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&&) @ 0x0000000012da74d9 4. /build/src/Functions/FunctionHelpers.cpp:130: DB::(anonymous namespace)::validateArgumentsImpl(DB::IFunction const&, std::vector> const&, unsigned long, std::vector> const&) @ 0x0000000012da5b15 5. /build/src/Functions/FunctionHelpers.cpp:192: DB::validateFunctionArguments(DB::IFunction const&, std::vector> const&, std::vector> const&, std::vector> const&) @ 0x0000000012da54fb 6. /build/src/Functions/FunctionsConversion.h:2234: DB::detail::FunctionConvert>, DB::detail::NameToDecimal64, DB::detail::UnknownMonotonicity>::getReturnTypeImplRemovedNullable(std::vector> const&) const @ 0x0000000012fcee39 7. /build/src/Functions/FunctionsConversion.h:2197: DB::detail::FunctionConvert>, DB::detail::NameToDecimal64, DB::detail::UnknownMonotonicity>::getReturnTypeImpl(std::vector> const&) const @ 0x0000000012fcecd5 8. /build/src/Functions/IFunction.cpp:645: DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x0000000012d96b0c 9. /build/src/Functions/IFunction.cpp:577: DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x0000000012d9669c 10. /build/src/Functions/IFunction.cpp:606: DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x0000000012d96edc 11. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3544: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000014033cc9 12. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3838: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000014019a9e 13. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3980: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000014018e31 14. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:4304: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000014042fa7 15. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5605: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000014013749 16. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000140127f9 17. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000014011fce 18. /build/src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000001406ce8a 19. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000014973b42 20. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000001497268d 21. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000014974d24 22. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001492924b 23. /build/src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88641 24. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 25. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 26. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 27. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 28. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 29. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 30. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 31. ? @ 0x00007fbc6213eac3 2025.07.28 11:51:19.762541 [ 11826 ] {93a5231c-6952-4782-b2ef-915073547e26} 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.6.10636.altinitytest (altinity build)) (from [::1]:50820) (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. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: 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&&) @ 0x0000000012da74d9 4. /build/src/Functions/FunctionHelpers.cpp:130: DB::(anonymous namespace)::validateArgumentsImpl(DB::IFunction const&, std::vector> const&, unsigned long, std::vector> const&) @ 0x0000000012da5b15 5. /build/src/Functions/FunctionHelpers.cpp:192: DB::validateFunctionArguments(DB::IFunction const&, std::vector> const&, std::vector> const&, std::vector> const&) @ 0x0000000012da54fb 6. /build/src/Functions/FunctionsConversion.h:2234: DB::detail::FunctionConvert>>, DB::detail::NameToDecimal128, DB::detail::UnknownMonotonicity>::getReturnTypeImplRemovedNullable(std::vector> const&) const @ 0x0000000012fd01f9 7. /build/src/Functions/FunctionsConversion.h:2197: DB::detail::FunctionConvert>>, DB::detail::NameToDecimal128, DB::detail::UnknownMonotonicity>::getReturnTypeImpl(std::vector> const&) const @ 0x0000000012fd0095 8. /build/src/Functions/IFunction.cpp:645: DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x0000000012d96b0c 9. /build/src/Functions/IFunction.cpp:577: DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x0000000012d9669c 10. /build/src/Functions/IFunction.cpp:606: DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x0000000012d96edc 11. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3544: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000014033cc9 12. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3838: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000014019a9e 13. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3980: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000014018e31 14. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:4304: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000014042fa7 15. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5605: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000014013749 16. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000140127f9 17. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000014011fce 18. /build/src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000001406ce8a 19. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000014973b42 20. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000001497268d 21. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000014974d24 22. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001492924b 23. /build/src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88641 24. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 25. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 26. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 27. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 28. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 29. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 30. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 31. ? @ 0x00007fbc6213eac3 2025.07.28 11:51:19.770139 [ 11826 ] {} 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. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: 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&&) @ 0x0000000012da74d9 4. /build/src/Functions/FunctionHelpers.cpp:130: DB::(anonymous namespace)::validateArgumentsImpl(DB::IFunction const&, std::vector> const&, unsigned long, std::vector> const&) @ 0x0000000012da5b15 5. /build/src/Functions/FunctionHelpers.cpp:192: DB::validateFunctionArguments(DB::IFunction const&, std::vector> const&, std::vector> const&, std::vector> const&) @ 0x0000000012da54fb 6. /build/src/Functions/FunctionsConversion.h:2234: DB::detail::FunctionConvert>>, DB::detail::NameToDecimal128, DB::detail::UnknownMonotonicity>::getReturnTypeImplRemovedNullable(std::vector> const&) const @ 0x0000000012fd01f9 7. /build/src/Functions/FunctionsConversion.h:2197: DB::detail::FunctionConvert>>, DB::detail::NameToDecimal128, DB::detail::UnknownMonotonicity>::getReturnTypeImpl(std::vector> const&) const @ 0x0000000012fd0095 8. /build/src/Functions/IFunction.cpp:645: DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x0000000012d96b0c 9. /build/src/Functions/IFunction.cpp:577: DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x0000000012d9669c 10. /build/src/Functions/IFunction.cpp:606: DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x0000000012d96edc 11. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3544: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000014033cc9 12. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3838: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000014019a9e 13. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3980: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000014018e31 14. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:4304: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000014042fa7 15. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5605: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000014013749 16. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000140127f9 17. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000014011fce 18. /build/src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000001406ce8a 19. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000014973b42 20. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000001497268d 21. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000014974d24 22. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001492924b 23. /build/src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88641 24. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 25. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 26. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 27. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 28. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 29. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 30. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 31. ? @ 0x00007fbc6213eac3 2025.07.28 11:51:20.012940 [ 11826 ] {21be144d-5614-4db6-b90a-b1b5d9d96bca} 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.6.10636.altinitytest (altinity build)) (from [::1]:50820) (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. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type>, char const* const&) @ 0x000000000a093dab 4. /build/src/DataTypes/DataTypesDecimal.cpp:282: void DB::convertToDecimalImpl, DB::DataTypeDecimal>, void>(T::FieldType const&, unsigned int, T0::FieldType&) @ 0x0000000013c308d8 5. /build/src/DataTypes/DataTypesDecimal.cpp:326: T0::FieldType DB::convertToDecimal, DB::DataTypeDecimal>>(T::FieldType const&, unsigned int) @ 0x0000000013c32d8b 6. /build/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) @ 0x000000001310bf94 7. /build/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 @ 0x00000000130fe884 8. /build/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&&) @ 0x0000000012fad239 9. /build/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 @ 0x0000000012fce44e 10. /build/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 @ 0x0000000012fcdc7a 11. /build/src/Functions/IFunction.h:437: DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000a069f2a 12. /build/src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000012d9965a 13. /build/src/Functions/IFunction.cpp:351: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d93b02 14. /build/src/Functions/IFunction.cpp:177: DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d93698 15. /build/src/Functions/IFunction.cpp:343: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d93aad 16. /build/src/Functions/IFunction.cpp:420: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d95059 17. /build/src/Functions/IFunction.cpp:498: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d95c72 18. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3567: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000014034494 19. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3838: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000014019a9e 20. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3980: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000014018e31 21. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:4304: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000014042fa7 22. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5605: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000014013749 23. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000140127f9 24. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000014011fce 25. /build/src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000001406ce8a 26. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000014973b42 27. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000001497268d 28. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000014974d24 29. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001492924b 30. /build/src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88641 31. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 2025.07.28 11:51:20.015940 [ 11826 ] {} 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. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type>, char const* const&) @ 0x000000000a093dab 4. /build/src/DataTypes/DataTypesDecimal.cpp:282: void DB::convertToDecimalImpl, DB::DataTypeDecimal>, void>(T::FieldType const&, unsigned int, T0::FieldType&) @ 0x0000000013c308d8 5. /build/src/DataTypes/DataTypesDecimal.cpp:326: T0::FieldType DB::convertToDecimal, DB::DataTypeDecimal>>(T::FieldType const&, unsigned int) @ 0x0000000013c32d8b 6. /build/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) @ 0x000000001310bf94 7. /build/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 @ 0x00000000130fe884 8. /build/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&&) @ 0x0000000012fad239 9. /build/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 @ 0x0000000012fce44e 10. /build/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 @ 0x0000000012fcdc7a 11. /build/src/Functions/IFunction.h:437: DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000a069f2a 12. /build/src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000012d9965a 13. /build/src/Functions/IFunction.cpp:351: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d93b02 14. /build/src/Functions/IFunction.cpp:177: DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d93698 15. /build/src/Functions/IFunction.cpp:343: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d93aad 16. /build/src/Functions/IFunction.cpp:420: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d95059 17. /build/src/Functions/IFunction.cpp:498: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d95c72 18. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3567: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000014034494 19. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3838: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000014019a9e 20. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3980: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000014018e31 21. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:4304: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000014042fa7 22. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5605: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000014013749 23. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000140127f9 24. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000014011fce 25. /build/src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000001406ce8a 26. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000014973b42 27. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000001497268d 28. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000014974d24 29. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001492924b 30. /build/src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88641 31. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 2025.07.28 11:51:20.225153 [ 11826 ] {f1c1e1bb-5eea-4d8e-b689-778ddf010346} 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.6.10636.altinitytest (altinity build)) (from [::1]:50820) (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. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type>, char const* const&) @ 0x000000000a093dab 4. /build/src/DataTypes/DataTypesDecimal.cpp:282: void DB::convertToDecimalImpl, DB::DataTypeDecimal>, void>(T::FieldType const&, unsigned int, T0::FieldType&) @ 0x0000000013c30b99 5. /build/src/DataTypes/DataTypesDecimal.cpp:326: T0::FieldType DB::convertToDecimal, DB::DataTypeDecimal>>(T::FieldType const&, unsigned int) @ 0x0000000013c331e9 6. /build/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) @ 0x00000000131246b5 7. /build/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 @ 0x0000000013116fa4 8. /build/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&&) @ 0x0000000012fad539 9. /build/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 @ 0x0000000012fcf80e 10. /build/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 @ 0x0000000012fcf03a 11. /build/src/Functions/IFunction.h:437: DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000a069f2a 12. /build/src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000012d9965a 13. /build/src/Functions/IFunction.cpp:351: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d93b02 14. /build/src/Functions/IFunction.cpp:177: DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d93698 15. /build/src/Functions/IFunction.cpp:343: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d93aad 16. /build/src/Functions/IFunction.cpp:420: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d95059 17. /build/src/Functions/IFunction.cpp:498: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d95c72 18. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3567: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000014034494 19. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3838: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000014019a9e 20. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3980: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000014018e31 21. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:4304: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000014042fa7 22. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5605: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000014013749 23. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000140127f9 24. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000014011fce 25. /build/src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000001406ce8a 26. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000014973b42 27. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000001497268d 28. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000014974d24 29. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001492924b 30. /build/src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88641 31. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 2025.07.28 11:51:20.230385 [ 11826 ] {} 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. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type>, char const* const&) @ 0x000000000a093dab 4. /build/src/DataTypes/DataTypesDecimal.cpp:282: void DB::convertToDecimalImpl, DB::DataTypeDecimal>, void>(T::FieldType const&, unsigned int, T0::FieldType&) @ 0x0000000013c30b99 5. /build/src/DataTypes/DataTypesDecimal.cpp:326: T0::FieldType DB::convertToDecimal, DB::DataTypeDecimal>>(T::FieldType const&, unsigned int) @ 0x0000000013c331e9 6. /build/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) @ 0x00000000131246b5 7. /build/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 @ 0x0000000013116fa4 8. /build/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&&) @ 0x0000000012fad539 9. /build/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 @ 0x0000000012fcf80e 10. /build/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 @ 0x0000000012fcf03a 11. /build/src/Functions/IFunction.h:437: DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000a069f2a 12. /build/src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000012d9965a 13. /build/src/Functions/IFunction.cpp:351: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d93b02 14. /build/src/Functions/IFunction.cpp:177: DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d93698 15. /build/src/Functions/IFunction.cpp:343: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d93aad 16. /build/src/Functions/IFunction.cpp:420: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d95059 17. /build/src/Functions/IFunction.cpp:498: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d95c72 18. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3567: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000014034494 19. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3838: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000014019a9e 20. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3980: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000014018e31 21. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:4304: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000014042fa7 22. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5605: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000014013749 23. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000140127f9 24. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000014011fce 25. /build/src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000001406ce8a 26. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000014973b42 27. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000001497268d 28. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000014974d24 29. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001492924b 30. /build/src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88641 31. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 2025.07.28 11:51:20.287372 [ 7625 ] {bcf63392-0bc0-43c9-95f7-31f62c9623a5} executeQuery: Code: 452. DB::Exception: Setting allow_experimental_object_type should not be changed. (SETTING_CONSTRAINT_VIOLATION) (version 25.3.6.10636.altinitytest (altinity build)) (from [::1]:38058) (comment: 01825_type_json_9.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. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x000000000c25bc4b 4. /build/src/Access/SettingsConstraints.cpp:343: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000138596e3 5. /build/src/Access/SettingsConstraints.cpp:300: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000013858faf 6. /build/src/Access/SettingsConstraints.cpp:194: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges const&, DB::SettingSource) const @ 0x00000000138591b3 7. /build/src/Interpreters/Context.cpp:2722: DB::Context::checkSettingsConstraints(DB::SettingsChanges const&, DB::SettingSource) @ 0x0000000014436509 8. /build/src/Interpreters/InterpreterSetQuery.cpp:28: DB::InterpreterSetQuery::execute() @ 0x00000000149e240a 9. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88dc9 10. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 11. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 12. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 13. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 14. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 16. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 17. ? @ 0x00007fbc6213eac3 18. ? @ 0x00007fbc621d0850 2025.07.28 11:51:20.307986 [ 7625 ] {} 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. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x000000000c25bc4b 4. /build/src/Access/SettingsConstraints.cpp:343: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000138596e3 5. /build/src/Access/SettingsConstraints.cpp:300: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000013858faf 6. /build/src/Access/SettingsConstraints.cpp:194: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges const&, DB::SettingSource) const @ 0x00000000138591b3 7. /build/src/Interpreters/Context.cpp:2722: DB::Context::checkSettingsConstraints(DB::SettingsChanges const&, DB::SettingSource) @ 0x0000000014436509 8. /build/src/Interpreters/InterpreterSetQuery.cpp:28: DB::InterpreterSetQuery::execute() @ 0x00000000149e240a 9. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88dc9 10. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 11. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 12. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 13. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 14. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 16. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 17. ? @ 0x00007fbc6213eac3 18. ? @ 0x00007fbc621d0850 2025.07.28 11:51:20.442396 [ 11826 ] {00f4b782-bd90-4dcd-b6f5-dbe2a225e203} 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.6.10636.altinitytest (altinity build)) (from [::1]:50820) (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. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type>, char const* const&) @ 0x000000000a093dab 4. /build/src/DataTypes/DataTypesDecimal.cpp:282: void DB::convertToDecimalImpl, DB::DataTypeDecimal>>, void>(T::FieldType const&, unsigned int, T0::FieldType&) @ 0x0000000013c31637 5. /build/src/DataTypes/DataTypesDecimal.cpp:326: T0::FieldType DB::convertToDecimal, DB::DataTypeDecimal>>>(T::FieldType const&, unsigned int) @ 0x0000000013c3384e 6. /build/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) @ 0x000000001313d274 7. /build/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 @ 0x000000001312f604 8. /build/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&&) @ 0x0000000012fad839 9. /build/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 @ 0x0000000012fd0bce 10. /build/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 @ 0x0000000012fd03fa 11. /build/src/Functions/IFunction.h:437: DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000a069f2a 12. /build/src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000012d9965a 13. /build/src/Functions/IFunction.cpp:351: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d93b02 14. /build/src/Functions/IFunction.cpp:177: DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d93698 15. /build/src/Functions/IFunction.cpp:343: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d93aad 16. /build/src/Functions/IFunction.cpp:420: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d95059 17. /build/src/Functions/IFunction.cpp:498: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d95c72 18. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3567: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000014034494 19. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3838: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000014019a9e 20. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3980: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000014018e31 21. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:4304: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000014042fa7 22. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5605: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000014013749 23. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000140127f9 24. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000014011fce 25. /build/src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000001406ce8a 26. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000014973b42 27. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000001497268d 28. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000014974d24 29. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001492924b 30. /build/src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88641 31. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 2025.07.28 11:51:20.446345 [ 11826 ] {} 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. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type>, char const* const&) @ 0x000000000a093dab 4. /build/src/DataTypes/DataTypesDecimal.cpp:282: void DB::convertToDecimalImpl, DB::DataTypeDecimal>>, void>(T::FieldType const&, unsigned int, T0::FieldType&) @ 0x0000000013c31637 5. /build/src/DataTypes/DataTypesDecimal.cpp:326: T0::FieldType DB::convertToDecimal, DB::DataTypeDecimal>>>(T::FieldType const&, unsigned int) @ 0x0000000013c3384e 6. /build/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) @ 0x000000001313d274 7. /build/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 @ 0x000000001312f604 8. /build/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&&) @ 0x0000000012fad839 9. /build/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 @ 0x0000000012fd0bce 10. /build/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 @ 0x0000000012fd03fa 11. /build/src/Functions/IFunction.h:437: DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000a069f2a 12. /build/src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000012d9965a 13. /build/src/Functions/IFunction.cpp:351: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d93b02 14. /build/src/Functions/IFunction.cpp:177: DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d93698 15. /build/src/Functions/IFunction.cpp:343: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d93aad 16. /build/src/Functions/IFunction.cpp:420: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d95059 17. /build/src/Functions/IFunction.cpp:498: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d95c72 18. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3567: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000014034494 19. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3838: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000014019a9e 20. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3980: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000014018e31 21. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:4304: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000014042fa7 22. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5605: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000014013749 23. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000140127f9 24. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000014011fce 25. /build/src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000001406ce8a 26. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000014973b42 27. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000001497268d 28. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000014974d24 29. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001492924b 30. /build/src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88641 31. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 2025.07.28 11:51:20.650961 [ 11826 ] {40aa96c6-434c-46f0-97e2-9a0fb303452d} 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.6.10636.altinitytest (altinity build)) (from [::1]:50820) (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. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type>, char const* const&) @ 0x000000000a093dab 4. /build/src/DataTypes/DataTypesDecimal.cpp:282: void DB::convertToDecimalImpl, DB::DataTypeDecimal>, void>(T::FieldType const&, unsigned int, T0::FieldType&) @ 0x0000000013c308d8 5. /build/src/DataTypes/DataTypesDecimal.cpp:326: T0::FieldType DB::convertToDecimal, DB::DataTypeDecimal>>(T::FieldType const&, unsigned int) @ 0x0000000013c32d8b 6. /build/src/Functions/FunctionsConversion.h:1764: 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) @ 0x0000000012ee1a54 7. /build/src/Functions/FunctionsConversion.h:3791: 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 @ 0x0000000012ed48f2 8. /build/src/Core/callOnTypeIndex.h:268: 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 @ 0x0000000012ed3068 9. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: COW::immutable_ptr std::__function::__policy_invoker::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)>::__call_impl[abi:se190107]::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) @ 0x0000000012ed2d2c 10. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000012ddcb1b 11. /build/src/Functions/IFunction.h:57: DB::IExecutableFunction::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000a08134a 12. /build/src/Functions/IFunction.cpp:351: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d93b02 13. /build/src/Functions/IFunction.cpp:177: DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d93698 14. /build/src/Functions/IFunction.cpp:343: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d93aad 15. /build/src/Functions/IFunction.cpp:424: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d94e1b 16. /build/src/Functions/IFunction.cpp:498: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d95c72 17. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3567: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000014034494 18. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3838: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000014019a9e 19. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3980: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000014018e31 20. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:4304: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000014042fa7 21. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5605: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000014013749 22. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000140127f9 23. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000014011fce 24. /build/src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000001406ce8a 25. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000014973b42 26. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000001497268d 27. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000014974d24 28. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001492924b 29. /build/src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88641 30. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 31. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 2025.07.28 11:51:20.655621 [ 11826 ] {} 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. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type>, char const* const&) @ 0x000000000a093dab 4. /build/src/DataTypes/DataTypesDecimal.cpp:282: void DB::convertToDecimalImpl, DB::DataTypeDecimal>, void>(T::FieldType const&, unsigned int, T0::FieldType&) @ 0x0000000013c308d8 5. /build/src/DataTypes/DataTypesDecimal.cpp:326: T0::FieldType DB::convertToDecimal, DB::DataTypeDecimal>>(T::FieldType const&, unsigned int) @ 0x0000000013c32d8b 6. /build/src/Functions/FunctionsConversion.h:1764: 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) @ 0x0000000012ee1a54 7. /build/src/Functions/FunctionsConversion.h:3791: 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 @ 0x0000000012ed48f2 8. /build/src/Core/callOnTypeIndex.h:268: 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 @ 0x0000000012ed3068 9. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: COW::immutable_ptr std::__function::__policy_invoker::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)>::__call_impl[abi:se190107]::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) @ 0x0000000012ed2d2c 10. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000012ddcb1b 11. /build/src/Functions/IFunction.h:57: DB::IExecutableFunction::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000a08134a 12. /build/src/Functions/IFunction.cpp:351: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d93b02 13. /build/src/Functions/IFunction.cpp:177: DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d93698 14. /build/src/Functions/IFunction.cpp:343: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d93aad 15. /build/src/Functions/IFunction.cpp:424: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d94e1b 16. /build/src/Functions/IFunction.cpp:498: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d95c72 17. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3567: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000014034494 18. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3838: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000014019a9e 19. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3980: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000014018e31 20. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:4304: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000014042fa7 21. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5605: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000014013749 22. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000140127f9 23. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000014011fce 24. /build/src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000001406ce8a 25. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000014973b42 26. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000001497268d 27. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000014974d24 28. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001492924b 29. /build/src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88641 30. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 31. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 2025.07.28 11:51:20.804665 [ 6322 ] {94e15498-1a26-4420-a68e-c3337f46bbb2} executeQuery: Code: 507. DB::Exception: Sharding key is not deterministic. (UNABLE_TO_SKIP_UNUSED_SHARDS) (version 25.3.6.10636.altinitytest (altinity build)) (from [::1]:38040) (comment: 01528_allow_nondeterministic_optimize_skip_unused_shards.sql) (query 5, line 8) (in query: select * from dist_01528 where dummy = 2;), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000000a074fcb 4. /build/src/Storages/StorageDistributed.cpp:1558: DB::StorageDistributed::getOptimizedCluster(std::shared_ptr, std::shared_ptr const&, DB::SelectQueryInfo const&, std::shared_ptr const&) const @ 0x0000000015d608d8 5. /build/src/Storages/StorageDistributed.cpp:457: DB::StorageDistributed::getQueryProcessingStage(std::shared_ptr, DB::QueryProcessingStage::Enum, std::shared_ptr const&, DB::SelectQueryInfo&) const @ 0x0000000015d5f50d 6. /build/src/Planner/PlannerJoinTree.cpp:921: DB::(anonymous namespace)::buildQueryPlanForTableExpression(std::shared_ptr, std::shared_ptr const&, DB::SelectQueryInfo const&, DB::SelectQueryOptions const&, std::shared_ptr&, bool, bool) @ 0x0000000014996f1b 7. /build/src/Planner/PlannerJoinTree.cpp:2252: DB::buildJoinTreeQueryPlan(std::shared_ptr const&, DB::SelectQueryInfo const&, DB::SelectQueryOptions&, std::unordered_set, std::equal_to, std::allocator> const&, std::shared_ptr&) @ 0x000000001498e109 8. /build/src/Planner/Planner.cpp:1553: DB::Planner::buildPlanForQueryNode() @ 0x0000000014979dae 9. /build/src/Planner/Planner.cpp:1308: DB::Planner::buildQueryPlanIfNeeded() @ 0x000000001497685c 10. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:255: DB::InterpreterSelectQueryAnalyzer::getQueryPlan() @ 0x000000001497476d 11. /build/src/Interpreters/executeQuery.cpp:1405: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88806 12. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 13. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 14. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 15. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 16. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 17. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 18. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 19. ? @ 0x00007fbc6213eac3 20. ? @ 0x00007fbc621d0850 2025.07.28 11:51:20.808776 [ 6322 ] {} 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. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000000a074fcb 4. /build/src/Storages/StorageDistributed.cpp:1558: DB::StorageDistributed::getOptimizedCluster(std::shared_ptr, std::shared_ptr const&, DB::SelectQueryInfo const&, std::shared_ptr const&) const @ 0x0000000015d608d8 5. /build/src/Storages/StorageDistributed.cpp:457: DB::StorageDistributed::getQueryProcessingStage(std::shared_ptr, DB::QueryProcessingStage::Enum, std::shared_ptr const&, DB::SelectQueryInfo&) const @ 0x0000000015d5f50d 6. /build/src/Planner/PlannerJoinTree.cpp:921: DB::(anonymous namespace)::buildQueryPlanForTableExpression(std::shared_ptr, std::shared_ptr const&, DB::SelectQueryInfo const&, DB::SelectQueryOptions const&, std::shared_ptr&, bool, bool) @ 0x0000000014996f1b 7. /build/src/Planner/PlannerJoinTree.cpp:2252: DB::buildJoinTreeQueryPlan(std::shared_ptr const&, DB::SelectQueryInfo const&, DB::SelectQueryOptions&, std::unordered_set, std::equal_to, std::allocator> const&, std::shared_ptr&) @ 0x000000001498e109 8. /build/src/Planner/Planner.cpp:1553: DB::Planner::buildPlanForQueryNode() @ 0x0000000014979dae 9. /build/src/Planner/Planner.cpp:1308: DB::Planner::buildQueryPlanIfNeeded() @ 0x000000001497685c 10. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:255: DB::InterpreterSelectQueryAnalyzer::getQueryPlan() @ 0x000000001497476d 11. /build/src/Interpreters/executeQuery.cpp:1405: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88806 12. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 13. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 14. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 15. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 16. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 17. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 18. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 19. ? @ 0x00007fbc6213eac3 20. ? @ 0x00007fbc621d0850 2025.07.28 11:51:20.966170 [ 11826 ] {9a0e111f-7822-4f65-910a-e8d1fc4f677a} 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.6.10636.altinitytest (altinity build)) (from [::1]:50820) (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. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type>, char const* const&) @ 0x000000000a093dab 4. /build/src/DataTypes/DataTypesDecimal.cpp:282: void DB::convertToDecimalImpl, DB::DataTypeDecimal>, void>(T::FieldType const&, unsigned int, T0::FieldType&) @ 0x0000000013c30b99 5. /build/src/DataTypes/DataTypesDecimal.cpp:326: T0::FieldType DB::convertToDecimal, DB::DataTypeDecimal>>(T::FieldType const&, unsigned int) @ 0x0000000013c331e9 6. /build/src/Functions/FunctionsConversion.h:1764: 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) @ 0x0000000012ef6b95 7. /build/src/Functions/FunctionsConversion.h:3791: 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 @ 0x0000000012ee9a32 8. /build/src/Core/callOnTypeIndex.h:268: 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 @ 0x0000000012ee81a8 9. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: COW::immutable_ptr std::__function::__policy_invoker::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)>::__call_impl[abi:se190107]::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) @ 0x0000000012ee7e6c 10. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000012ddcb1b 11. /build/src/Functions/IFunction.h:57: DB::IExecutableFunction::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000a08134a 12. /build/src/Functions/IFunction.cpp:351: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d93b02 13. /build/src/Functions/IFunction.cpp:177: DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d93698 14. /build/src/Functions/IFunction.cpp:343: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d93aad 15. /build/src/Functions/IFunction.cpp:424: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d94e1b 16. /build/src/Functions/IFunction.cpp:498: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d95c72 17. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3567: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000014034494 18. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3838: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000014019a9e 19. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3980: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000014018e31 20. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:4304: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000014042fa7 21. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5605: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000014013749 22. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000140127f9 23. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000014011fce 24. /build/src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000001406ce8a 25. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000014973b42 26. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000001497268d 27. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000014974d24 28. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001492924b 29. /build/src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88641 30. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 31. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 2025.07.28 11:51:20.973326 [ 11826 ] {} 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. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type>, char const* const&) @ 0x000000000a093dab 4. /build/src/DataTypes/DataTypesDecimal.cpp:282: void DB::convertToDecimalImpl, DB::DataTypeDecimal>, void>(T::FieldType const&, unsigned int, T0::FieldType&) @ 0x0000000013c30b99 5. /build/src/DataTypes/DataTypesDecimal.cpp:326: T0::FieldType DB::convertToDecimal, DB::DataTypeDecimal>>(T::FieldType const&, unsigned int) @ 0x0000000013c331e9 6. /build/src/Functions/FunctionsConversion.h:1764: 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) @ 0x0000000012ef6b95 7. /build/src/Functions/FunctionsConversion.h:3791: 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 @ 0x0000000012ee9a32 8. /build/src/Core/callOnTypeIndex.h:268: 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 @ 0x0000000012ee81a8 9. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: COW::immutable_ptr std::__function::__policy_invoker::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)>::__call_impl[abi:se190107]::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) @ 0x0000000012ee7e6c 10. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000012ddcb1b 11. /build/src/Functions/IFunction.h:57: DB::IExecutableFunction::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000a08134a 12. /build/src/Functions/IFunction.cpp:351: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d93b02 13. /build/src/Functions/IFunction.cpp:177: DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d93698 14. /build/src/Functions/IFunction.cpp:343: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d93aad 15. /build/src/Functions/IFunction.cpp:424: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d94e1b 16. /build/src/Functions/IFunction.cpp:498: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d95c72 17. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3567: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000014034494 18. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3838: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000014019a9e 19. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3980: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000014018e31 20. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:4304: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000014042fa7 21. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5605: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000014013749 22. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000140127f9 23. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000014011fce 24. /build/src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000001406ce8a 25. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000014973b42 26. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000001497268d 27. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000014974d24 28. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001492924b 29. /build/src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88641 30. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 31. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 2025.07.28 11:51:21.126175 [ 11826 ] {e3d172d1-c18f-489a-87e8-28dd11b72282} 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.6.10636.altinitytest (altinity build)) (from [::1]:50820) (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. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type>, char const* const&) @ 0x000000000a093dab 4. /build/src/DataTypes/DataTypesDecimal.cpp:282: void DB::convertToDecimalImpl, DB::DataTypeDecimal>>, void>(T::FieldType const&, unsigned int, T0::FieldType&) @ 0x0000000013c31637 5. /build/src/DataTypes/DataTypesDecimal.cpp:326: T0::FieldType DB::convertToDecimal, DB::DataTypeDecimal>>>(T::FieldType const&, unsigned int) @ 0x0000000013c3384e 6. /build/src/Functions/FunctionsConversion.h:1764: 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) @ 0x0000000012f0bff4 7. /build/src/Functions/FunctionsConversion.h:3791: 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 @ 0x0000000012efeaf2 8. /build/src/Core/callOnTypeIndex.h:268: 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 @ 0x0000000012efd268 9. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: COW::immutable_ptr std::__function::__policy_invoker::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)>::__call_impl[abi:se190107]::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) @ 0x0000000012efcf2c 10. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000012ddcb1b 11. /build/src/Functions/IFunction.h:57: DB::IExecutableFunction::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000a08134a 12. /build/src/Functions/IFunction.cpp:351: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d93b02 13. /build/src/Functions/IFunction.cpp:177: DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d93698 14. /build/src/Functions/IFunction.cpp:343: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d93aad 15. /build/src/Functions/IFunction.cpp:424: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d94e1b 16. /build/src/Functions/IFunction.cpp:498: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d95c72 17. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3567: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000014034494 18. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3838: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000014019a9e 19. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3980: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000014018e31 20. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:4304: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000014042fa7 21. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5605: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000014013749 22. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000140127f9 23. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000014011fce 24. /build/src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000001406ce8a 25. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000014973b42 26. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000001497268d 27. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000014974d24 28. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001492924b 29. /build/src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88641 30. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 31. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 2025.07.28 11:51:21.149352 [ 11826 ] {} 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. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type>, char const* const&) @ 0x000000000a093dab 4. /build/src/DataTypes/DataTypesDecimal.cpp:282: void DB::convertToDecimalImpl, DB::DataTypeDecimal>>, void>(T::FieldType const&, unsigned int, T0::FieldType&) @ 0x0000000013c31637 5. /build/src/DataTypes/DataTypesDecimal.cpp:326: T0::FieldType DB::convertToDecimal, DB::DataTypeDecimal>>>(T::FieldType const&, unsigned int) @ 0x0000000013c3384e 6. /build/src/Functions/FunctionsConversion.h:1764: 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) @ 0x0000000012f0bff4 7. /build/src/Functions/FunctionsConversion.h:3791: 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 @ 0x0000000012efeaf2 8. /build/src/Core/callOnTypeIndex.h:268: 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 @ 0x0000000012efd268 9. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: COW::immutable_ptr std::__function::__policy_invoker::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)>::__call_impl[abi:se190107]::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) @ 0x0000000012efcf2c 10. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000012ddcb1b 11. /build/src/Functions/IFunction.h:57: DB::IExecutableFunction::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000a08134a 12. /build/src/Functions/IFunction.cpp:351: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d93b02 13. /build/src/Functions/IFunction.cpp:177: DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d93698 14. /build/src/Functions/IFunction.cpp:343: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d93aad 15. /build/src/Functions/IFunction.cpp:424: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d94e1b 16. /build/src/Functions/IFunction.cpp:498: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d95c72 17. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3567: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000014034494 18. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3838: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000014019a9e 19. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3980: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000014018e31 20. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:4304: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000014042fa7 21. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5605: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000014013749 22. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000140127f9 23. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000014011fce 24. /build/src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000001406ce8a 25. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000014973b42 26. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000001497268d 27. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000014974d24 28. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001492924b 29. /build/src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88641 30. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 31. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 2025.07.28 11:51:21.355113 [ 11826 ] {9eca12a6-c6c4-42a8-bcf2-5dc1e7c9366a} 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.6.10636.altinitytest (altinity build)) (from [::1]:50820) (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. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type>, char const* const&) @ 0x000000000a093dab 4. /build/src/DataTypes/DataTypesDecimal.cpp:282: void DB::convertToDecimalImpl, DB::DataTypeDecimal>, void>(T::FieldType const&, unsigned int, T0::FieldType&) @ 0x0000000013c308d8 5. /build/src/DataTypes/DataTypesDecimal.cpp:326: T0::FieldType DB::convertToDecimal, DB::DataTypeDecimal>>(T::FieldType const&, unsigned int) @ 0x0000000013c32d8b 6. /build/src/Functions/FunctionsConversion.h:1764: 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) @ 0x0000000012ee1a54 7. /build/src/Functions/FunctionsConversion.h:3791: 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 @ 0x0000000012ed48f2 8. /build/src/Core/callOnTypeIndex.h:268: 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 @ 0x0000000012ed3068 9. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: COW::immutable_ptr std::__function::__policy_invoker::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)>::__call_impl[abi:se190107]::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) @ 0x0000000012ed2d2c 10. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000012ddcb1b 11. /build/src/Functions/IFunction.h:57: DB::IExecutableFunction::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000a08134a 12. /build/src/Functions/IFunction.cpp:351: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d93b02 13. /build/src/Functions/IFunction.cpp:177: DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d93698 14. /build/src/Functions/IFunction.cpp:343: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d93aad 15. /build/src/Functions/IFunction.cpp:424: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d94e1b 16. /build/src/Functions/IFunction.cpp:498: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d95c72 17. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3567: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000014034494 18. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3838: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000014019a9e 19. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3980: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000014018e31 20. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:4304: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000014042fa7 21. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5605: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000014013749 22. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000140127f9 23. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000014011fce 24. /build/src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000001406ce8a 25. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000014973b42 26. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000001497268d 27. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000014974d24 28. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001492924b 29. /build/src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88641 30. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 31. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 2025.07.28 11:51:21.361137 [ 11826 ] {} 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. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type>, char const* const&) @ 0x000000000a093dab 4. /build/src/DataTypes/DataTypesDecimal.cpp:282: void DB::convertToDecimalImpl, DB::DataTypeDecimal>, void>(T::FieldType const&, unsigned int, T0::FieldType&) @ 0x0000000013c308d8 5. /build/src/DataTypes/DataTypesDecimal.cpp:326: T0::FieldType DB::convertToDecimal, DB::DataTypeDecimal>>(T::FieldType const&, unsigned int) @ 0x0000000013c32d8b 6. /build/src/Functions/FunctionsConversion.h:1764: 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) @ 0x0000000012ee1a54 7. /build/src/Functions/FunctionsConversion.h:3791: 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 @ 0x0000000012ed48f2 8. /build/src/Core/callOnTypeIndex.h:268: 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 @ 0x0000000012ed3068 9. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: COW::immutable_ptr std::__function::__policy_invoker::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)>::__call_impl[abi:se190107]::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) @ 0x0000000012ed2d2c 10. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000012ddcb1b 11. /build/src/Functions/IFunction.h:57: DB::IExecutableFunction::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000a08134a 12. /build/src/Functions/IFunction.cpp:351: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d93b02 13. /build/src/Functions/IFunction.cpp:177: DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d93698 14. /build/src/Functions/IFunction.cpp:343: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d93aad 15. /build/src/Functions/IFunction.cpp:424: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d94e1b 16. /build/src/Functions/IFunction.cpp:498: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d95c72 17. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3567: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000014034494 18. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3838: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000014019a9e 19. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3980: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000014018e31 20. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:4304: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000014042fa7 21. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5605: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000014013749 22. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000140127f9 23. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000014011fce 24. /build/src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000001406ce8a 25. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000014973b42 26. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000001497268d 27. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000014974d24 28. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001492924b 29. /build/src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88641 30. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 31. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 2025.07.28 11:51:21.531405 [ 11826 ] {d845ced2-3455-4020-a612-f1a40906a38c} 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.6.10636.altinitytest (altinity build)) (from [::1]:50820) (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. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type>, char const* const&) @ 0x000000000a093dab 4. /build/src/DataTypes/DataTypesDecimal.cpp:282: void DB::convertToDecimalImpl, DB::DataTypeDecimal>, void>(T::FieldType const&, unsigned int, T0::FieldType&) @ 0x0000000013c30b99 5. /build/src/DataTypes/DataTypesDecimal.cpp:326: T0::FieldType DB::convertToDecimal, DB::DataTypeDecimal>>(T::FieldType const&, unsigned int) @ 0x0000000013c331e9 6. /build/src/Functions/FunctionsConversion.h:1764: 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) @ 0x0000000012ef6b95 7. /build/src/Functions/FunctionsConversion.h:3791: 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 @ 0x0000000012ee9a32 8. /build/src/Core/callOnTypeIndex.h:268: 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 @ 0x0000000012ee81a8 9. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: COW::immutable_ptr std::__function::__policy_invoker::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)>::__call_impl[abi:se190107]::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) @ 0x0000000012ee7e6c 10. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000012ddcb1b 11. /build/src/Functions/IFunction.h:57: DB::IExecutableFunction::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000a08134a 12. /build/src/Functions/IFunction.cpp:351: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d93b02 13. /build/src/Functions/IFunction.cpp:177: DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d93698 14. /build/src/Functions/IFunction.cpp:343: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d93aad 15. /build/src/Functions/IFunction.cpp:424: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d94e1b 16. /build/src/Functions/IFunction.cpp:498: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d95c72 17. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3567: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000014034494 18. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3838: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000014019a9e 19. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3980: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000014018e31 20. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:4304: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000014042fa7 21. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5605: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000014013749 22. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000140127f9 23. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000014011fce 24. /build/src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000001406ce8a 25. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000014973b42 26. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000001497268d 27. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000014974d24 28. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001492924b 29. /build/src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88641 30. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 31. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 2025.07.28 11:51:21.534158 [ 11826 ] {} 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. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type>, char const* const&) @ 0x000000000a093dab 4. /build/src/DataTypes/DataTypesDecimal.cpp:282: void DB::convertToDecimalImpl, DB::DataTypeDecimal>, void>(T::FieldType const&, unsigned int, T0::FieldType&) @ 0x0000000013c30b99 5. /build/src/DataTypes/DataTypesDecimal.cpp:326: T0::FieldType DB::convertToDecimal, DB::DataTypeDecimal>>(T::FieldType const&, unsigned int) @ 0x0000000013c331e9 6. /build/src/Functions/FunctionsConversion.h:1764: 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) @ 0x0000000012ef6b95 7. /build/src/Functions/FunctionsConversion.h:3791: 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 @ 0x0000000012ee9a32 8. /build/src/Core/callOnTypeIndex.h:268: 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 @ 0x0000000012ee81a8 9. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: COW::immutable_ptr std::__function::__policy_invoker::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)>::__call_impl[abi:se190107]::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) @ 0x0000000012ee7e6c 10. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000012ddcb1b 11. /build/src/Functions/IFunction.h:57: DB::IExecutableFunction::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000a08134a 12. /build/src/Functions/IFunction.cpp:351: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d93b02 13. /build/src/Functions/IFunction.cpp:177: DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d93698 14. /build/src/Functions/IFunction.cpp:343: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d93aad 15. /build/src/Functions/IFunction.cpp:424: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d94e1b 16. /build/src/Functions/IFunction.cpp:498: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d95c72 17. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3567: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000014034494 18. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3838: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000014019a9e 19. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3980: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000014018e31 20. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:4304: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000014042fa7 21. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5605: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000014013749 22. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000140127f9 23. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000014011fce 24. /build/src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000001406ce8a 25. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000014973b42 26. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000001497268d 27. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000014974d24 28. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001492924b 29. /build/src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88641 30. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 31. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 2025.07.28 11:51:21.605189 [ 11826 ] {dea0bd88-4428-4fdc-8f2a-07716c79bca9} 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.6.10636.altinitytest (altinity build)) (from [::1]:50820) (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. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type>, char const* const&) @ 0x000000000a093dab 4. /build/src/DataTypes/DataTypesDecimal.cpp:282: void DB::convertToDecimalImpl, DB::DataTypeDecimal>>, void>(T::FieldType const&, unsigned int, T0::FieldType&) @ 0x0000000013c31637 5. /build/src/DataTypes/DataTypesDecimal.cpp:326: T0::FieldType DB::convertToDecimal, DB::DataTypeDecimal>>>(T::FieldType const&, unsigned int) @ 0x0000000013c3384e 6. /build/src/Functions/FunctionsConversion.h:1764: 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) @ 0x0000000012f0bff4 7. /build/src/Functions/FunctionsConversion.h:3791: 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 @ 0x0000000012efeaf2 8. /build/src/Core/callOnTypeIndex.h:268: 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 @ 0x0000000012efd268 9. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: COW::immutable_ptr std::__function::__policy_invoker::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)>::__call_impl[abi:se190107]::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) @ 0x0000000012efcf2c 10. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000012ddcb1b 11. /build/src/Functions/IFunction.h:57: DB::IExecutableFunction::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000a08134a 12. /build/src/Functions/IFunction.cpp:351: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d93b02 13. /build/src/Functions/IFunction.cpp:177: DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d93698 14. /build/src/Functions/IFunction.cpp:343: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d93aad 15. /build/src/Functions/IFunction.cpp:424: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d94e1b 16. /build/src/Functions/IFunction.cpp:498: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d95c72 17. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3567: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000014034494 18. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3838: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000014019a9e 19. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3980: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000014018e31 20. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:4304: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000014042fa7 21. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5605: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000014013749 22. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000140127f9 23. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000014011fce 24. /build/src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000001406ce8a 25. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000014973b42 26. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000001497268d 27. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000014974d24 28. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001492924b 29. /build/src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88641 30. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 31. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 2025.07.28 11:51:21.636544 [ 11826 ] {} 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. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type>, char const* const&) @ 0x000000000a093dab 4. /build/src/DataTypes/DataTypesDecimal.cpp:282: void DB::convertToDecimalImpl, DB::DataTypeDecimal>>, void>(T::FieldType const&, unsigned int, T0::FieldType&) @ 0x0000000013c31637 5. /build/src/DataTypes/DataTypesDecimal.cpp:326: T0::FieldType DB::convertToDecimal, DB::DataTypeDecimal>>>(T::FieldType const&, unsigned int) @ 0x0000000013c3384e 6. /build/src/Functions/FunctionsConversion.h:1764: 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) @ 0x0000000012f0bff4 7. /build/src/Functions/FunctionsConversion.h:3791: 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 @ 0x0000000012efeaf2 8. /build/src/Core/callOnTypeIndex.h:268: 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 @ 0x0000000012efd268 9. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: COW::immutable_ptr std::__function::__policy_invoker::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)>::__call_impl[abi:se190107]::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) @ 0x0000000012efcf2c 10. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000012ddcb1b 11. /build/src/Functions/IFunction.h:57: DB::IExecutableFunction::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000a08134a 12. /build/src/Functions/IFunction.cpp:351: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d93b02 13. /build/src/Functions/IFunction.cpp:177: DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d93698 14. /build/src/Functions/IFunction.cpp:343: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d93aad 15. /build/src/Functions/IFunction.cpp:424: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d94e1b 16. /build/src/Functions/IFunction.cpp:498: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d95c72 17. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3567: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000014034494 18. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3838: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000014019a9e 19. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3980: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000014018e31 20. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:4304: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000014042fa7 21. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5605: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000014013749 22. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000140127f9 23. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000014011fce 24. /build/src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000001406ce8a 25. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000014973b42 26. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000001497268d 27. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000014974d24 28. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001492924b 29. /build/src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88641 30. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 31. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 2025.07.28 11:51:21.698799 [ 4581 ] {d3c6bfee-c241-4cec-b8b1-772b00b182a9} executeQuery: Code: 452. DB::Exception: Setting allow_experimental_object_type should not be changed. (SETTING_CONSTRAINT_VIOLATION) (version 25.3.6.10636.altinitytest (altinity build)) (from [::1]:47026) (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. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x000000000c25bc4b 4. /build/src/Access/SettingsConstraints.cpp:343: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000138596e3 5. /build/src/Access/SettingsConstraints.cpp:300: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000013858faf 6. /build/src/Access/SettingsConstraints.cpp:194: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges const&, DB::SettingSource) const @ 0x00000000138591b3 7. /build/src/Interpreters/Context.cpp:2722: DB::Context::checkSettingsConstraints(DB::SettingsChanges const&, DB::SettingSource) @ 0x0000000014436509 8. /build/src/Interpreters/InterpreterSetQuery.cpp:28: DB::InterpreterSetQuery::execute() @ 0x00000000149e240a 9. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88dc9 10. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 11. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 12. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 13. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 14. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 16. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 17. ? @ 0x00007fbc6213eac3 18. ? @ 0x00007fbc621d0850 2025.07.28 11:51:21.720767 [ 4581 ] {} 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. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x000000000c25bc4b 4. /build/src/Access/SettingsConstraints.cpp:343: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000138596e3 5. /build/src/Access/SettingsConstraints.cpp:300: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000013858faf 6. /build/src/Access/SettingsConstraints.cpp:194: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges const&, DB::SettingSource) const @ 0x00000000138591b3 7. /build/src/Interpreters/Context.cpp:2722: DB::Context::checkSettingsConstraints(DB::SettingsChanges const&, DB::SettingSource) @ 0x0000000014436509 8. /build/src/Interpreters/InterpreterSetQuery.cpp:28: DB::InterpreterSetQuery::execute() @ 0x00000000149e240a 9. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88dc9 10. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 11. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 12. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 13. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 14. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 16. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 17. ? @ 0x00007fbc6213eac3 18. ? @ 0x00007fbc621d0850 2025.07.28 11:51:21.911151 [ 5327 ] {a1a4ed5b-dbfd-418f-9cb1-5946e5950c74} executeQuery: Code: 407. DB::Exception: Intermediate result overflow (signed a = 9223372036854775807, signed b = -9223372036854775808, min = -9223372036854775808, max = 9223372036854775807): In scope SELECT gcd(9223372036854775807, -9223372036854775808). (DECIMAL_OVERFLOW) (version 25.3.6.10636.altinitytest (altinity build)) (from [::1]:47030) (comment: 01666_gcd_ubsan.sql) (query 1, line 1) (in query: -- { echo } SELECT gcd(9223372036854775807, -9223372036854775808);), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, long&, long&, long&, long&) @ 0x000000000ba4130b 4. /build/src/Functions/GCDLCMImpl.h:44: long DB::GCDLCMImpl, DB::(anonymous namespace)::NameGCD>::apply(unsigned long, long) @ 0x000000000b9c7f40 5. /build/src/Functions/FunctionBinaryArithmetic.h:309: _ZN2DBL16castTypeToEitherIJNS_14DataTypeNumberIDuEENS1_ItEENS1_IjEENS1_ImEENS1_IN4wide7integerILm128EjEEEENS1_INS7_ILm256EjEEEENS1_IDB8_EENS1_IsEENS1_IiEENS1_IlEENS1_INS7_ILm128EiEEEENS1_INS7_ILm256EiEEEENS_15DataTypeDecimalINS_7DecimalIiEEEENSL_INSM_IlEEEENSL_INSM_ISH_EEEENSL_INSM_ISJ_EEEENS_12DataTypeDateENS_16DataTypeDateTimeENS_19DataTypeFixedStringENS_14DataTypeStringENS_16DataTypeIntervalEENS_9IDataTypeEZZNS_24FunctionBinaryArithmeticINS_12_GLOBAL__N_17GCDImplENS12_7NameGCDELb0ELb0ELb0EE13castBothTypesIZNKS15_12executeImpl2ERKNSt3__16vectorINS_21ColumnWithTypeAndNameENS17_9allocatorIS19_EEEERKNS17_10shared_ptrIKS10_EEmPKNS_8PODArrayIDuLm4096E9AllocatorILb0ELb0EELm63ELm64EEEEUlRKT_RKT0_E_EEbPS1G_S1X_OS1Q_ENKUlS1S_E_clIS5_EEDaS1S_EUlS1S_E_EEb8TypeListIJDpT_EEPS1U_OT1_ @ 0x000000000ba04ee9 6. /build/src/Functions/FunctionBinaryArithmetic.h:838: DB::FunctionBinaryArithmetic::executeImpl2(std::vector> const&, std::shared_ptr const&, unsigned long, DB::PODArray, 63ul, 64ul> const*) const @ 0x000000000b9ea301 7. /build/src/Functions/FunctionBinaryArithmetic.h:2410: DB::FunctionBinaryArithmetic::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000b9e8c17 8. /build/src/Functions/FunctionBinaryArithmetic.h:2645: DB::FunctionBinaryArithmeticWithConstants::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000b9e7bb4 9. /build/src/Functions/IFunction.h:437: DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000a069f2a 10. /build/src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000012d9965a 11. /build/src/Functions/IFunction.cpp:351: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d93b02 12. /build/src/Functions/IFunction.cpp:420: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d95059 13. /build/src/Functions/IFunction.cpp:498: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d95c72 14. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3567: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000014034494 15. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3838: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000014019a9e 16. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3980: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000014018e31 17. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:4304: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000014042fa7 18. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5605: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000014013749 19. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000140127f9 20. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000014011fce 21. /build/src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000001406ce8a 22. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000014973b42 23. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000001497268d 24. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000014974d24 25. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001492924b 26. /build/src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88641 27. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 28. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 29. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 30. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 31. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 2025.07.28 11:51:21.912236 [ 11826 ] {cbb6db14-6e40-4170-bc2b-dc9bc6bdc8f1} 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.6.10636.altinitytest (altinity build)) (from [::1]:50820) (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. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type>, char const* const&) @ 0x000000000a093dab 4. /build/src/DataTypes/DataTypesDecimal.cpp:293: void DB::convertToDecimalImpl, DB::DataTypeDecimal>, void>(T::FieldType const&, unsigned int, T0::FieldType&) @ 0x0000000013c30935 5. /build/src/DataTypes/DataTypesDecimal.cpp:326: T0::FieldType DB::convertToDecimal, DB::DataTypeDecimal>>(T::FieldType const&, unsigned int) @ 0x0000000013c32d8b 6. /build/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) @ 0x000000001310bf94 7. /build/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 @ 0x00000000130fe884 8. /build/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&&) @ 0x0000000012fad239 9. /build/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 @ 0x0000000012fce44e 10. /build/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 @ 0x0000000012fcdc7a 11. /build/src/Functions/IFunction.h:437: DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000a069f2a 12. /build/src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000012d9965a 13. /build/src/Functions/IFunction.cpp:351: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d93b02 14. /build/src/Functions/IFunction.cpp:177: DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d93698 15. /build/src/Functions/IFunction.cpp:343: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d93aad 16. /build/src/Functions/IFunction.cpp:420: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d95059 17. /build/src/Functions/IFunction.cpp:498: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d95c72 18. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3567: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000014034494 19. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3838: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000014019a9e 20. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3980: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000014018e31 21. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:4304: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000014042fa7 22. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5605: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000014013749 23. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000140127f9 24. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000014011fce 25. /build/src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000001406ce8a 26. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000014973b42 27. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000001497268d 28. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000014974d24 29. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001492924b 30. /build/src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88641 31. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 2025.07.28 11:51:21.923356 [ 11826 ] {} 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. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type>, char const* const&) @ 0x000000000a093dab 4. /build/src/DataTypes/DataTypesDecimal.cpp:293: void DB::convertToDecimalImpl, DB::DataTypeDecimal>, void>(T::FieldType const&, unsigned int, T0::FieldType&) @ 0x0000000013c30935 5. /build/src/DataTypes/DataTypesDecimal.cpp:326: T0::FieldType DB::convertToDecimal, DB::DataTypeDecimal>>(T::FieldType const&, unsigned int) @ 0x0000000013c32d8b 6. /build/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) @ 0x000000001310bf94 7. /build/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 @ 0x00000000130fe884 8. /build/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&&) @ 0x0000000012fad239 9. /build/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 @ 0x0000000012fce44e 10. /build/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 @ 0x0000000012fcdc7a 11. /build/src/Functions/IFunction.h:437: DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000a069f2a 12. /build/src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000012d9965a 13. /build/src/Functions/IFunction.cpp:351: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d93b02 14. /build/src/Functions/IFunction.cpp:177: DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d93698 15. /build/src/Functions/IFunction.cpp:343: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d93aad 16. /build/src/Functions/IFunction.cpp:420: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d95059 17. /build/src/Functions/IFunction.cpp:498: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d95c72 18. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3567: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000014034494 19. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3838: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000014019a9e 20. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3980: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000014018e31 21. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:4304: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000014042fa7 22. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5605: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000014013749 23. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000140127f9 24. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000014011fce 25. /build/src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000001406ce8a 26. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000014973b42 27. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000001497268d 28. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000014974d24 29. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001492924b 30. /build/src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88641 31. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 2025.07.28 11:51:21.923923 [ 5327 ] {} TCPHandler: Code: 407. DB::Exception: Intermediate result overflow (signed a = 9223372036854775807, signed b = -9223372036854775808, min = -9223372036854775808, max = 9223372036854775807): In scope SELECT gcd(9223372036854775807, -9223372036854775808). (DECIMAL_OVERFLOW), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, long&, long&, long&, long&) @ 0x000000000ba4130b 4. /build/src/Functions/GCDLCMImpl.h:44: long DB::GCDLCMImpl, DB::(anonymous namespace)::NameGCD>::apply(unsigned long, long) @ 0x000000000b9c7f40 5. /build/src/Functions/FunctionBinaryArithmetic.h:309: _ZN2DBL16castTypeToEitherIJNS_14DataTypeNumberIDuEENS1_ItEENS1_IjEENS1_ImEENS1_IN4wide7integerILm128EjEEEENS1_INS7_ILm256EjEEEENS1_IDB8_EENS1_IsEENS1_IiEENS1_IlEENS1_INS7_ILm128EiEEEENS1_INS7_ILm256EiEEEENS_15DataTypeDecimalINS_7DecimalIiEEEENSL_INSM_IlEEEENSL_INSM_ISH_EEEENSL_INSM_ISJ_EEEENS_12DataTypeDateENS_16DataTypeDateTimeENS_19DataTypeFixedStringENS_14DataTypeStringENS_16DataTypeIntervalEENS_9IDataTypeEZZNS_24FunctionBinaryArithmeticINS_12_GLOBAL__N_17GCDImplENS12_7NameGCDELb0ELb0ELb0EE13castBothTypesIZNKS15_12executeImpl2ERKNSt3__16vectorINS_21ColumnWithTypeAndNameENS17_9allocatorIS19_EEEERKNS17_10shared_ptrIKS10_EEmPKNS_8PODArrayIDuLm4096E9AllocatorILb0ELb0EELm63ELm64EEEEUlRKT_RKT0_E_EEbPS1G_S1X_OS1Q_ENKUlS1S_E_clIS5_EEDaS1S_EUlS1S_E_EEb8TypeListIJDpT_EEPS1U_OT1_ @ 0x000000000ba04ee9 6. /build/src/Functions/FunctionBinaryArithmetic.h:838: DB::FunctionBinaryArithmetic::executeImpl2(std::vector> const&, std::shared_ptr const&, unsigned long, DB::PODArray, 63ul, 64ul> const*) const @ 0x000000000b9ea301 7. /build/src/Functions/FunctionBinaryArithmetic.h:2410: DB::FunctionBinaryArithmetic::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000b9e8c17 8. /build/src/Functions/FunctionBinaryArithmetic.h:2645: DB::FunctionBinaryArithmeticWithConstants::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000b9e7bb4 9. /build/src/Functions/IFunction.h:437: DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000a069f2a 10. /build/src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000012d9965a 11. /build/src/Functions/IFunction.cpp:351: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d93b02 12. /build/src/Functions/IFunction.cpp:420: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d95059 13. /build/src/Functions/IFunction.cpp:498: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d95c72 14. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3567: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000014034494 15. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3838: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000014019a9e 16. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3980: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000014018e31 17. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:4304: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000014042fa7 18. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5605: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000014013749 19. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000140127f9 20. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000014011fce 21. /build/src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000001406ce8a 22. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000014973b42 23. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000001497268d 24. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000014974d24 25. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001492924b 26. /build/src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88641 27. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 28. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 29. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 30. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 31. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 2025.07.28 11:51:22.037339 [ 5327 ] {5b33eec5-d20e-4d57-913a-0cd90d629de6} executeQuery: Code: 407. DB::Exception: Intermediate result overflow (signed a = -9223372036854775808, signed b = -9223372036854775807, min = -9223372036854775808, max = 9223372036854775807): In scope SELECT gcd(9223372036854775808, -9223372036854775807). (DECIMAL_OVERFLOW) (version 25.3.6.10636.altinitytest (altinity build)) (from [::1]:47030) (comment: 01666_gcd_ubsan.sql) (query 2, line 3) (in query: SELECT gcd(9223372036854775808, -9223372036854775807);), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, long&, long&, long&, long&) @ 0x000000000ba4130b 4. /build/src/Functions/GCDLCMImpl.h:44: long DB::GCDLCMImpl, DB::(anonymous namespace)::NameGCD>::apply(unsigned long, long) @ 0x000000000b9c7f40 5. /build/src/Functions/FunctionBinaryArithmetic.h:309: _ZN2DBL16castTypeToEitherIJNS_14DataTypeNumberIDuEENS1_ItEENS1_IjEENS1_ImEENS1_IN4wide7integerILm128EjEEEENS1_INS7_ILm256EjEEEENS1_IDB8_EENS1_IsEENS1_IiEENS1_IlEENS1_INS7_ILm128EiEEEENS1_INS7_ILm256EiEEEENS_15DataTypeDecimalINS_7DecimalIiEEEENSL_INSM_IlEEEENSL_INSM_ISH_EEEENSL_INSM_ISJ_EEEENS_12DataTypeDateENS_16DataTypeDateTimeENS_19DataTypeFixedStringENS_14DataTypeStringENS_16DataTypeIntervalEENS_9IDataTypeEZZNS_24FunctionBinaryArithmeticINS_12_GLOBAL__N_17GCDImplENS12_7NameGCDELb0ELb0ELb0EE13castBothTypesIZNKS15_12executeImpl2ERKNSt3__16vectorINS_21ColumnWithTypeAndNameENS17_9allocatorIS19_EEEERKNS17_10shared_ptrIKS10_EEmPKNS_8PODArrayIDuLm4096E9AllocatorILb0ELb0EELm63ELm64EEEEUlRKT_RKT0_E_EEbPS1G_S1X_OS1Q_ENKUlS1S_E_clIS5_EEDaS1S_EUlS1S_E_EEb8TypeListIJDpT_EEPS1U_OT1_ @ 0x000000000ba04ee9 6. /build/src/Functions/FunctionBinaryArithmetic.h:838: DB::FunctionBinaryArithmetic::executeImpl2(std::vector> const&, std::shared_ptr const&, unsigned long, DB::PODArray, 63ul, 64ul> const*) const @ 0x000000000b9ea301 7. /build/src/Functions/FunctionBinaryArithmetic.h:2410: DB::FunctionBinaryArithmetic::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000b9e8c17 8. /build/src/Functions/FunctionBinaryArithmetic.h:2645: DB::FunctionBinaryArithmeticWithConstants::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000b9e7bb4 9. /build/src/Functions/IFunction.h:437: DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000a069f2a 10. /build/src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000012d9965a 11. /build/src/Functions/IFunction.cpp:351: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d93b02 12. /build/src/Functions/IFunction.cpp:420: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d95059 13. /build/src/Functions/IFunction.cpp:498: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d95c72 14. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3567: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000014034494 15. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3838: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000014019a9e 16. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3980: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000014018e31 17. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:4304: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000014042fa7 18. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5605: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000014013749 19. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000140127f9 20. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000014011fce 21. /build/src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000001406ce8a 22. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000014973b42 23. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000001497268d 24. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000014974d24 25. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001492924b 26. /build/src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88641 27. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 28. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 29. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 30. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 31. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 2025.07.28 11:51:22.062682 [ 5327 ] {} TCPHandler: Code: 407. DB::Exception: Intermediate result overflow (signed a = -9223372036854775808, signed b = -9223372036854775807, min = -9223372036854775808, max = 9223372036854775807): In scope SELECT gcd(9223372036854775808, -9223372036854775807). (DECIMAL_OVERFLOW), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, long&, long&, long&, long&) @ 0x000000000ba4130b 4. /build/src/Functions/GCDLCMImpl.h:44: long DB::GCDLCMImpl, DB::(anonymous namespace)::NameGCD>::apply(unsigned long, long) @ 0x000000000b9c7f40 5. /build/src/Functions/FunctionBinaryArithmetic.h:309: _ZN2DBL16castTypeToEitherIJNS_14DataTypeNumberIDuEENS1_ItEENS1_IjEENS1_ImEENS1_IN4wide7integerILm128EjEEEENS1_INS7_ILm256EjEEEENS1_IDB8_EENS1_IsEENS1_IiEENS1_IlEENS1_INS7_ILm128EiEEEENS1_INS7_ILm256EiEEEENS_15DataTypeDecimalINS_7DecimalIiEEEENSL_INSM_IlEEEENSL_INSM_ISH_EEEENSL_INSM_ISJ_EEEENS_12DataTypeDateENS_16DataTypeDateTimeENS_19DataTypeFixedStringENS_14DataTypeStringENS_16DataTypeIntervalEENS_9IDataTypeEZZNS_24FunctionBinaryArithmeticINS_12_GLOBAL__N_17GCDImplENS12_7NameGCDELb0ELb0ELb0EE13castBothTypesIZNKS15_12executeImpl2ERKNSt3__16vectorINS_21ColumnWithTypeAndNameENS17_9allocatorIS19_EEEERKNS17_10shared_ptrIKS10_EEmPKNS_8PODArrayIDuLm4096E9AllocatorILb0ELb0EELm63ELm64EEEEUlRKT_RKT0_E_EEbPS1G_S1X_OS1Q_ENKUlS1S_E_clIS5_EEDaS1S_EUlS1S_E_EEb8TypeListIJDpT_EEPS1U_OT1_ @ 0x000000000ba04ee9 6. /build/src/Functions/FunctionBinaryArithmetic.h:838: DB::FunctionBinaryArithmetic::executeImpl2(std::vector> const&, std::shared_ptr const&, unsigned long, DB::PODArray, 63ul, 64ul> const*) const @ 0x000000000b9ea301 7. /build/src/Functions/FunctionBinaryArithmetic.h:2410: DB::FunctionBinaryArithmetic::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000b9e8c17 8. /build/src/Functions/FunctionBinaryArithmetic.h:2645: DB::FunctionBinaryArithmeticWithConstants::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000b9e7bb4 9. /build/src/Functions/IFunction.h:437: DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000a069f2a 10. /build/src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000012d9965a 11. /build/src/Functions/IFunction.cpp:351: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d93b02 12. /build/src/Functions/IFunction.cpp:420: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d95059 13. /build/src/Functions/IFunction.cpp:498: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d95c72 14. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3567: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000014034494 15. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3838: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000014019a9e 16. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3980: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000014018e31 17. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:4304: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000014042fa7 18. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5605: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000014013749 19. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000140127f9 20. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000014011fce 21. /build/src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000001406ce8a 22. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000014973b42 23. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000001497268d 24. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000014974d24 25. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001492924b 26. /build/src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88641 27. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 28. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 29. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 30. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 31. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 2025.07.28 11:51:22.082402 [ 11826 ] {294ef663-01c8-4f05-9d8f-a0a4a479ea97} 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.6.10636.altinitytest (altinity build)) (from [::1]:50820) (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. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type>, char const* const&) @ 0x000000000a093dab 4. /build/src/DataTypes/DataTypesDecimal.cpp:293: void DB::convertToDecimalImpl, DB::DataTypeDecimal>, void>(T::FieldType const&, unsigned int, T0::FieldType&) @ 0x0000000013c30bf6 5. /build/src/DataTypes/DataTypesDecimal.cpp:326: T0::FieldType DB::convertToDecimal, DB::DataTypeDecimal>>(T::FieldType const&, unsigned int) @ 0x0000000013c331e9 6. /build/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) @ 0x00000000131246b5 7. /build/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 @ 0x0000000013116fa4 8. /build/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&&) @ 0x0000000012fad539 9. /build/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 @ 0x0000000012fcf80e 10. /build/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 @ 0x0000000012fcf03a 11. /build/src/Functions/IFunction.h:437: DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000a069f2a 12. /build/src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000012d9965a 13. /build/src/Functions/IFunction.cpp:351: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d93b02 14. /build/src/Functions/IFunction.cpp:177: DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d93698 15. /build/src/Functions/IFunction.cpp:343: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d93aad 16. /build/src/Functions/IFunction.cpp:420: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d95059 17. /build/src/Functions/IFunction.cpp:498: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d95c72 18. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3567: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000014034494 19. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3838: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000014019a9e 20. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3980: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000014018e31 21. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:4304: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000014042fa7 22. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5605: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000014013749 23. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000140127f9 24. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000014011fce 25. /build/src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000001406ce8a 26. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000014973b42 27. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000001497268d 28. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000014974d24 29. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001492924b 30. /build/src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88641 31. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 2025.07.28 11:51:22.096146 [ 11826 ] {} 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. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type>, char const* const&) @ 0x000000000a093dab 4. /build/src/DataTypes/DataTypesDecimal.cpp:293: void DB::convertToDecimalImpl, DB::DataTypeDecimal>, void>(T::FieldType const&, unsigned int, T0::FieldType&) @ 0x0000000013c30bf6 5. /build/src/DataTypes/DataTypesDecimal.cpp:326: T0::FieldType DB::convertToDecimal, DB::DataTypeDecimal>>(T::FieldType const&, unsigned int) @ 0x0000000013c331e9 6. /build/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) @ 0x00000000131246b5 7. /build/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 @ 0x0000000013116fa4 8. /build/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&&) @ 0x0000000012fad539 9. /build/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 @ 0x0000000012fcf80e 10. /build/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 @ 0x0000000012fcf03a 11. /build/src/Functions/IFunction.h:437: DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000a069f2a 12. /build/src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000012d9965a 13. /build/src/Functions/IFunction.cpp:351: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d93b02 14. /build/src/Functions/IFunction.cpp:177: DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d93698 15. /build/src/Functions/IFunction.cpp:343: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d93aad 16. /build/src/Functions/IFunction.cpp:420: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d95059 17. /build/src/Functions/IFunction.cpp:498: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d95c72 18. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3567: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000014034494 19. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3838: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000014019a9e 20. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3980: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000014018e31 21. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:4304: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000014042fa7 22. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5605: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000014013749 23. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000140127f9 24. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000014011fce 25. /build/src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000001406ce8a 26. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000014973b42 27. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000001497268d 28. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000014974d24 29. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001492924b 30. /build/src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88641 31. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 2025.07.28 11:51:22.204498 [ 5327 ] {3f3576e5-4a48-4d7d-8c96-95dccd57d20e} executeQuery: Code: 407. DB::Exception: Intermediate result overflow (signed a = -9223372036854775808, signed b = 9223372036854775807, min = -9223372036854775808, max = 9223372036854775807): In scope SELECT gcd(-9223372036854775808, 9223372036854775807). (DECIMAL_OVERFLOW) (version 25.3.6.10636.altinitytest (altinity build)) (from [::1]:47030) (comment: 01666_gcd_ubsan.sql) (query 3, line 4) (in query: SELECT gcd(-9223372036854775808, 9223372036854775807);), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, long&, long&, long&, long&) @ 0x000000000ba4130b 4. /build/src/Functions/GCDLCMImpl.h:44: long DB::GCDLCMImpl, DB::(anonymous namespace)::NameGCD>::apply(long, unsigned long) @ 0x000000000b9dbfe0 5. /build/src/Functions/FunctionBinaryArithmetic.h:309: _ZN2DBL16castTypeToEitherIJNS_14DataTypeNumberIDuEENS1_ItEENS1_IjEENS1_ImEENS1_IN4wide7integerILm128EjEEEENS1_INS7_ILm256EjEEEENS1_IDB8_EENS1_IsEENS1_IiEENS1_IlEENS1_INS7_ILm128EiEEEENS1_INS7_ILm256EiEEEENS_15DataTypeDecimalINS_7DecimalIiEEEENSL_INSM_IlEEEENSL_INSM_ISH_EEEENSL_INSM_ISJ_EEEENS_12DataTypeDateENS_16DataTypeDateTimeENS_19DataTypeFixedStringENS_14DataTypeStringENS_16DataTypeIntervalEENS_9IDataTypeEZZNS_24FunctionBinaryArithmeticINS_12_GLOBAL__N_17GCDImplENS12_7NameGCDELb0ELb0ELb0EE13castBothTypesIZNKS15_12executeImpl2ERKNSt3__16vectorINS_21ColumnWithTypeAndNameENS17_9allocatorIS19_EEEERKNS17_10shared_ptrIKS10_EEmPKNS_8PODArrayIDuLm4096E9AllocatorILb0ELb0EELm63ELm64EEEEUlRKT_RKT0_E_EEbPS1G_S1X_OS1Q_ENKUlS1S_E_clISG_EEDaS1S_EUlS1S_E_EEb8TypeListIJDpT_EEPS1U_OT1_ @ 0x000000000ba24c49 6. /build/src/Functions/FunctionBinaryArithmetic.h:838: DB::FunctionBinaryArithmetic::executeImpl2(std::vector> const&, std::shared_ptr const&, unsigned long, DB::PODArray, 63ul, 64ul> const*) const @ 0x000000000b9ea5c1 7. /build/src/Functions/FunctionBinaryArithmetic.h:2410: DB::FunctionBinaryArithmetic::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000b9e8c17 8. /build/src/Functions/FunctionBinaryArithmetic.h:2645: DB::FunctionBinaryArithmeticWithConstants::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000b9e7bb4 9. /build/src/Functions/IFunction.h:437: DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000a069f2a 10. /build/src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000012d9965a 11. /build/src/Functions/IFunction.cpp:351: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d93b02 12. /build/src/Functions/IFunction.cpp:420: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d95059 13. /build/src/Functions/IFunction.cpp:498: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d95c72 14. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3567: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000014034494 15. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3838: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000014019a9e 16. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3980: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000014018e31 17. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:4304: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000014042fa7 18. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5605: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000014013749 19. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000140127f9 20. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000014011fce 21. /build/src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000001406ce8a 22. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000014973b42 23. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000001497268d 24. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000014974d24 25. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001492924b 26. /build/src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88641 27. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 28. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 29. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 30. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 31. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 2025.07.28 11:51:22.227484 [ 5327 ] {} TCPHandler: Code: 407. DB::Exception: Intermediate result overflow (signed a = -9223372036854775808, signed b = 9223372036854775807, min = -9223372036854775808, max = 9223372036854775807): In scope SELECT gcd(-9223372036854775808, 9223372036854775807). (DECIMAL_OVERFLOW), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, long&, long&, long&, long&) @ 0x000000000ba4130b 4. /build/src/Functions/GCDLCMImpl.h:44: long DB::GCDLCMImpl, DB::(anonymous namespace)::NameGCD>::apply(long, unsigned long) @ 0x000000000b9dbfe0 5. /build/src/Functions/FunctionBinaryArithmetic.h:309: _ZN2DBL16castTypeToEitherIJNS_14DataTypeNumberIDuEENS1_ItEENS1_IjEENS1_ImEENS1_IN4wide7integerILm128EjEEEENS1_INS7_ILm256EjEEEENS1_IDB8_EENS1_IsEENS1_IiEENS1_IlEENS1_INS7_ILm128EiEEEENS1_INS7_ILm256EiEEEENS_15DataTypeDecimalINS_7DecimalIiEEEENSL_INSM_IlEEEENSL_INSM_ISH_EEEENSL_INSM_ISJ_EEEENS_12DataTypeDateENS_16DataTypeDateTimeENS_19DataTypeFixedStringENS_14DataTypeStringENS_16DataTypeIntervalEENS_9IDataTypeEZZNS_24FunctionBinaryArithmeticINS_12_GLOBAL__N_17GCDImplENS12_7NameGCDELb0ELb0ELb0EE13castBothTypesIZNKS15_12executeImpl2ERKNSt3__16vectorINS_21ColumnWithTypeAndNameENS17_9allocatorIS19_EEEERKNS17_10shared_ptrIKS10_EEmPKNS_8PODArrayIDuLm4096E9AllocatorILb0ELb0EELm63ELm64EEEEUlRKT_RKT0_E_EEbPS1G_S1X_OS1Q_ENKUlS1S_E_clISG_EEDaS1S_EUlS1S_E_EEb8TypeListIJDpT_EEPS1U_OT1_ @ 0x000000000ba24c49 6. /build/src/Functions/FunctionBinaryArithmetic.h:838: DB::FunctionBinaryArithmetic::executeImpl2(std::vector> const&, std::shared_ptr const&, unsigned long, DB::PODArray, 63ul, 64ul> const*) const @ 0x000000000b9ea5c1 7. /build/src/Functions/FunctionBinaryArithmetic.h:2410: DB::FunctionBinaryArithmetic::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000b9e8c17 8. /build/src/Functions/FunctionBinaryArithmetic.h:2645: DB::FunctionBinaryArithmeticWithConstants::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000b9e7bb4 9. /build/src/Functions/IFunction.h:437: DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000a069f2a 10. /build/src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000012d9965a 11. /build/src/Functions/IFunction.cpp:351: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d93b02 12. /build/src/Functions/IFunction.cpp:420: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d95059 13. /build/src/Functions/IFunction.cpp:498: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d95c72 14. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3567: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000014034494 15. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3838: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000014019a9e 16. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3980: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000014018e31 17. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:4304: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000014042fa7 18. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5605: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000014013749 19. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000140127f9 20. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000014011fce 21. /build/src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000001406ce8a 22. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000014973b42 23. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000001497268d 24. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000014974d24 25. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001492924b 26. /build/src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88641 27. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 28. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 29. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 30. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 31. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 2025.07.28 11:51:22.290327 [ 5327 ] {6f836d99-a216-4c12-ba4d-42be2584c657} executeQuery: Code: 407. DB::Exception: Intermediate result overflow (signed a = -9223372036854775807, signed b = -9223372036854775808, min = -9223372036854775808, max = 9223372036854775807): In scope SELECT gcd(-9223372036854775807, 9223372036854775808). (DECIMAL_OVERFLOW) (version 25.3.6.10636.altinitytest (altinity build)) (from [::1]:47030) (comment: 01666_gcd_ubsan.sql) (query 4, line 5) (in query: SELECT gcd(-9223372036854775807, 9223372036854775808);), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, long&, long&, long&, long&) @ 0x000000000ba4130b 4. /build/src/Functions/GCDLCMImpl.h:44: long DB::GCDLCMImpl, DB::(anonymous namespace)::NameGCD>::apply(long, unsigned long) @ 0x000000000b9dbfe0 5. /build/src/Functions/FunctionBinaryArithmetic.h:309: _ZN2DBL16castTypeToEitherIJNS_14DataTypeNumberIDuEENS1_ItEENS1_IjEENS1_ImEENS1_IN4wide7integerILm128EjEEEENS1_INS7_ILm256EjEEEENS1_IDB8_EENS1_IsEENS1_IiEENS1_IlEENS1_INS7_ILm128EiEEEENS1_INS7_ILm256EiEEEENS_15DataTypeDecimalINS_7DecimalIiEEEENSL_INSM_IlEEEENSL_INSM_ISH_EEEENSL_INSM_ISJ_EEEENS_12DataTypeDateENS_16DataTypeDateTimeENS_19DataTypeFixedStringENS_14DataTypeStringENS_16DataTypeIntervalEENS_9IDataTypeEZZNS_24FunctionBinaryArithmeticINS_12_GLOBAL__N_17GCDImplENS12_7NameGCDELb0ELb0ELb0EE13castBothTypesIZNKS15_12executeImpl2ERKNSt3__16vectorINS_21ColumnWithTypeAndNameENS17_9allocatorIS19_EEEERKNS17_10shared_ptrIKS10_EEmPKNS_8PODArrayIDuLm4096E9AllocatorILb0ELb0EELm63ELm64EEEEUlRKT_RKT0_E_EEbPS1G_S1X_OS1Q_ENKUlS1S_E_clISG_EEDaS1S_EUlS1S_E_EEb8TypeListIJDpT_EEPS1U_OT1_ @ 0x000000000ba24c49 6. /build/src/Functions/FunctionBinaryArithmetic.h:838: DB::FunctionBinaryArithmetic::executeImpl2(std::vector> const&, std::shared_ptr const&, unsigned long, DB::PODArray, 63ul, 64ul> const*) const @ 0x000000000b9ea5c1 7. /build/src/Functions/FunctionBinaryArithmetic.h:2410: DB::FunctionBinaryArithmetic::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000b9e8c17 8. /build/src/Functions/FunctionBinaryArithmetic.h:2645: DB::FunctionBinaryArithmeticWithConstants::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000b9e7bb4 9. /build/src/Functions/IFunction.h:437: DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000a069f2a 10. /build/src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000012d9965a 11. /build/src/Functions/IFunction.cpp:351: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d93b02 12. /build/src/Functions/IFunction.cpp:420: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d95059 13. /build/src/Functions/IFunction.cpp:498: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d95c72 14. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3567: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000014034494 15. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3838: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000014019a9e 16. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3980: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000014018e31 17. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:4304: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000014042fa7 18. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5605: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000014013749 19. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000140127f9 20. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000014011fce 21. /build/src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000001406ce8a 22. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000014973b42 23. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000001497268d 24. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000014974d24 25. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001492924b 26. /build/src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88641 27. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 28. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 29. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 30. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 31. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 2025.07.28 11:51:22.306130 [ 5327 ] {} TCPHandler: Code: 407. DB::Exception: Intermediate result overflow (signed a = -9223372036854775807, signed b = -9223372036854775808, min = -9223372036854775808, max = 9223372036854775807): In scope SELECT gcd(-9223372036854775807, 9223372036854775808). (DECIMAL_OVERFLOW), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, long&, long&, long&, long&) @ 0x000000000ba4130b 4. /build/src/Functions/GCDLCMImpl.h:44: long DB::GCDLCMImpl, DB::(anonymous namespace)::NameGCD>::apply(long, unsigned long) @ 0x000000000b9dbfe0 5. /build/src/Functions/FunctionBinaryArithmetic.h:309: _ZN2DBL16castTypeToEitherIJNS_14DataTypeNumberIDuEENS1_ItEENS1_IjEENS1_ImEENS1_IN4wide7integerILm128EjEEEENS1_INS7_ILm256EjEEEENS1_IDB8_EENS1_IsEENS1_IiEENS1_IlEENS1_INS7_ILm128EiEEEENS1_INS7_ILm256EiEEEENS_15DataTypeDecimalINS_7DecimalIiEEEENSL_INSM_IlEEEENSL_INSM_ISH_EEEENSL_INSM_ISJ_EEEENS_12DataTypeDateENS_16DataTypeDateTimeENS_19DataTypeFixedStringENS_14DataTypeStringENS_16DataTypeIntervalEENS_9IDataTypeEZZNS_24FunctionBinaryArithmeticINS_12_GLOBAL__N_17GCDImplENS12_7NameGCDELb0ELb0ELb0EE13castBothTypesIZNKS15_12executeImpl2ERKNSt3__16vectorINS_21ColumnWithTypeAndNameENS17_9allocatorIS19_EEEERKNS17_10shared_ptrIKS10_EEmPKNS_8PODArrayIDuLm4096E9AllocatorILb0ELb0EELm63ELm64EEEEUlRKT_RKT0_E_EEbPS1G_S1X_OS1Q_ENKUlS1S_E_clISG_EEDaS1S_EUlS1S_E_EEb8TypeListIJDpT_EEPS1U_OT1_ @ 0x000000000ba24c49 6. /build/src/Functions/FunctionBinaryArithmetic.h:838: DB::FunctionBinaryArithmetic::executeImpl2(std::vector> const&, std::shared_ptr const&, unsigned long, DB::PODArray, 63ul, 64ul> const*) const @ 0x000000000b9ea5c1 7. /build/src/Functions/FunctionBinaryArithmetic.h:2410: DB::FunctionBinaryArithmetic::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000b9e8c17 8. /build/src/Functions/FunctionBinaryArithmetic.h:2645: DB::FunctionBinaryArithmeticWithConstants::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000b9e7bb4 9. /build/src/Functions/IFunction.h:437: DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000a069f2a 10. /build/src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000012d9965a 11. /build/src/Functions/IFunction.cpp:351: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d93b02 12. /build/src/Functions/IFunction.cpp:420: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d95059 13. /build/src/Functions/IFunction.cpp:498: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d95c72 14. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3567: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000014034494 15. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3838: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000014019a9e 16. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3980: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000014018e31 17. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:4304: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000014042fa7 18. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5605: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000014013749 19. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000140127f9 20. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000014011fce 21. /build/src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000001406ce8a 22. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000014973b42 23. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000001497268d 24. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000014974d24 25. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001492924b 26. /build/src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88641 27. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 28. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 29. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 30. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 31. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 2025.07.28 11:51:22.338812 [ 11826 ] {fcfbef56-1e86-42e2-b79b-e4119ef1e235} 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.6.10636.altinitytest (altinity build)) (from [::1]:50820) (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. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type>, char const* const&) @ 0x000000000a093dab 4. /build/src/DataTypes/DataTypesDecimal.cpp:293: void DB::convertToDecimalImpl, DB::DataTypeDecimal>>, void>(T::FieldType const&, unsigned int, T0::FieldType&) @ 0x0000000013c315c8 5. /build/src/DataTypes/DataTypesDecimal.cpp:326: T0::FieldType DB::convertToDecimal, DB::DataTypeDecimal>>>(T::FieldType const&, unsigned int) @ 0x0000000013c3384e 6. /build/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) @ 0x000000001313d274 7. /build/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 @ 0x000000001312f604 8. /build/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&&) @ 0x0000000012fad839 9. /build/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 @ 0x0000000012fd0bce 10. /build/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 @ 0x0000000012fd03fa 11. /build/src/Functions/IFunction.h:437: DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000a069f2a 12. /build/src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000012d9965a 13. /build/src/Functions/IFunction.cpp:351: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d93b02 14. /build/src/Functions/IFunction.cpp:177: DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d93698 15. /build/src/Functions/IFunction.cpp:343: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d93aad 16. /build/src/Functions/IFunction.cpp:420: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d95059 17. /build/src/Functions/IFunction.cpp:498: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d95c72 18. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3567: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000014034494 19. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3838: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000014019a9e 20. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3980: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000014018e31 21. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:4304: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000014042fa7 22. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5605: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000014013749 23. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000140127f9 24. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000014011fce 25. /build/src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000001406ce8a 26. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000014973b42 27. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000001497268d 28. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000014974d24 29. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001492924b 30. /build/src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88641 31. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 2025.07.28 11:51:22.342013 [ 11826 ] {} 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. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type>, char const* const&) @ 0x000000000a093dab 4. /build/src/DataTypes/DataTypesDecimal.cpp:293: void DB::convertToDecimalImpl, DB::DataTypeDecimal>>, void>(T::FieldType const&, unsigned int, T0::FieldType&) @ 0x0000000013c315c8 5. /build/src/DataTypes/DataTypesDecimal.cpp:326: T0::FieldType DB::convertToDecimal, DB::DataTypeDecimal>>>(T::FieldType const&, unsigned int) @ 0x0000000013c3384e 6. /build/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) @ 0x000000001313d274 7. /build/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 @ 0x000000001312f604 8. /build/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&&) @ 0x0000000012fad839 9. /build/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 @ 0x0000000012fd0bce 10. /build/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 @ 0x0000000012fd03fa 11. /build/src/Functions/IFunction.h:437: DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000a069f2a 12. /build/src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000012d9965a 13. /build/src/Functions/IFunction.cpp:351: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d93b02 14. /build/src/Functions/IFunction.cpp:177: DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d93698 15. /build/src/Functions/IFunction.cpp:343: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d93aad 16. /build/src/Functions/IFunction.cpp:420: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d95059 17. /build/src/Functions/IFunction.cpp:498: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d95c72 18. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3567: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000014034494 19. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3838: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000014019a9e 20. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3980: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000014018e31 21. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:4304: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000014042fa7 22. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5605: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000014013749 23. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000140127f9 24. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000014011fce 25. /build/src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000001406ce8a 26. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000014973b42 27. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000001497268d 28. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000014974d24 29. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001492924b 30. /build/src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88641 31. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 2025.07.28 11:51:22.429657 [ 11826 ] {7f13bd15-537f-41de-a036-ad81b6bb7040} 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.6.10636.altinitytest (altinity build)) (from [::1]:50820) (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. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type>, char const* const&) @ 0x000000000a093dab 4. /build/src/DataTypes/DataTypesDecimal.cpp:293: void DB::convertToDecimalImpl, DB::DataTypeDecimal>, void>(T::FieldType const&, unsigned int, T0::FieldType&) @ 0x0000000013c30935 5. /build/src/DataTypes/DataTypesDecimal.cpp:326: T0::FieldType DB::convertToDecimal, DB::DataTypeDecimal>>(T::FieldType const&, unsigned int) @ 0x0000000013c32d8b 6. /build/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) @ 0x000000001310bf94 7. /build/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 @ 0x00000000130fe884 8. /build/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&&) @ 0x0000000012fad239 9. /build/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 @ 0x0000000012fce44e 10. /build/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 @ 0x0000000012fcdc7a 11. /build/src/Functions/IFunction.h:437: DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000a069f2a 12. /build/src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000012d9965a 13. /build/src/Functions/IFunction.cpp:351: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d93b02 14. /build/src/Functions/IFunction.cpp:177: DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d93698 15. /build/src/Functions/IFunction.cpp:343: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d93aad 16. /build/src/Functions/IFunction.cpp:420: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d95059 17. /build/src/Functions/IFunction.cpp:498: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d95c72 18. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3567: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000014034494 19. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3838: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000014019a9e 20. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3980: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000014018e31 21. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:4304: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000014042fa7 22. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5605: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000014013749 23. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000140127f9 24. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000014011fce 25. /build/src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000001406ce8a 26. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000014973b42 27. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000001497268d 28. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000014974d24 29. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001492924b 30. /build/src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88641 31. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 2025.07.28 11:51:22.454449 [ 11826 ] {} 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. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type>, char const* const&) @ 0x000000000a093dab 4. /build/src/DataTypes/DataTypesDecimal.cpp:293: void DB::convertToDecimalImpl, DB::DataTypeDecimal>, void>(T::FieldType const&, unsigned int, T0::FieldType&) @ 0x0000000013c30935 5. /build/src/DataTypes/DataTypesDecimal.cpp:326: T0::FieldType DB::convertToDecimal, DB::DataTypeDecimal>>(T::FieldType const&, unsigned int) @ 0x0000000013c32d8b 6. /build/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) @ 0x000000001310bf94 7. /build/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 @ 0x00000000130fe884 8. /build/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&&) @ 0x0000000012fad239 9. /build/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 @ 0x0000000012fce44e 10. /build/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 @ 0x0000000012fcdc7a 11. /build/src/Functions/IFunction.h:437: DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000a069f2a 12. /build/src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000012d9965a 13. /build/src/Functions/IFunction.cpp:351: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d93b02 14. /build/src/Functions/IFunction.cpp:177: DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d93698 15. /build/src/Functions/IFunction.cpp:343: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d93aad 16. /build/src/Functions/IFunction.cpp:420: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d95059 17. /build/src/Functions/IFunction.cpp:498: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d95c72 18. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3567: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000014034494 19. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3838: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000014019a9e 20. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3980: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000014018e31 21. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:4304: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000014042fa7 22. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5605: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000014013749 23. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000140127f9 24. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000014011fce 25. /build/src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000001406ce8a 26. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000014973b42 27. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000001497268d 28. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000014974d24 29. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001492924b 30. /build/src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88641 31. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 2025.07.28 11:51:22.517915 [ 11826 ] {f8a02cdb-1d5c-41e1-b8aa-dd585349a16a} 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.6.10636.altinitytest (altinity build)) (from [::1]:50820) (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. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type>, char const* const&) @ 0x000000000a093dab 4. /build/src/DataTypes/DataTypesDecimal.cpp:293: void DB::convertToDecimalImpl, DB::DataTypeDecimal>, void>(T::FieldType const&, unsigned int, T0::FieldType&) @ 0x0000000013c30bf6 5. /build/src/DataTypes/DataTypesDecimal.cpp:326: T0::FieldType DB::convertToDecimal, DB::DataTypeDecimal>>(T::FieldType const&, unsigned int) @ 0x0000000013c331e9 6. /build/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) @ 0x00000000131246b5 7. /build/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 @ 0x0000000013116fa4 8. /build/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&&) @ 0x0000000012fad539 9. /build/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 @ 0x0000000012fcf80e 10. /build/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 @ 0x0000000012fcf03a 11. /build/src/Functions/IFunction.h:437: DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000a069f2a 12. /build/src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000012d9965a 13. /build/src/Functions/IFunction.cpp:351: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d93b02 14. /build/src/Functions/IFunction.cpp:177: DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d93698 15. /build/src/Functions/IFunction.cpp:343: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d93aad 16. /build/src/Functions/IFunction.cpp:420: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d95059 17. /build/src/Functions/IFunction.cpp:498: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d95c72 18. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3567: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000014034494 19. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3838: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000014019a9e 20. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3980: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000014018e31 21. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:4304: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000014042fa7 22. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5605: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000014013749 23. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000140127f9 24. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000014011fce 25. /build/src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000001406ce8a 26. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000014973b42 27. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000001497268d 28. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000014974d24 29. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001492924b 30. /build/src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88641 31. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 2025.07.28 11:51:22.528889 [ 11826 ] {} 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. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type>, char const* const&) @ 0x000000000a093dab 4. /build/src/DataTypes/DataTypesDecimal.cpp:293: void DB::convertToDecimalImpl, DB::DataTypeDecimal>, void>(T::FieldType const&, unsigned int, T0::FieldType&) @ 0x0000000013c30bf6 5. /build/src/DataTypes/DataTypesDecimal.cpp:326: T0::FieldType DB::convertToDecimal, DB::DataTypeDecimal>>(T::FieldType const&, unsigned int) @ 0x0000000013c331e9 6. /build/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) @ 0x00000000131246b5 7. /build/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 @ 0x0000000013116fa4 8. /build/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&&) @ 0x0000000012fad539 9. /build/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 @ 0x0000000012fcf80e 10. /build/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 @ 0x0000000012fcf03a 11. /build/src/Functions/IFunction.h:437: DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000a069f2a 12. /build/src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000012d9965a 13. /build/src/Functions/IFunction.cpp:351: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d93b02 14. /build/src/Functions/IFunction.cpp:177: DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d93698 15. /build/src/Functions/IFunction.cpp:343: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d93aad 16. /build/src/Functions/IFunction.cpp:420: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d95059 17. /build/src/Functions/IFunction.cpp:498: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d95c72 18. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3567: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000014034494 19. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3838: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000014019a9e 20. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3980: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000014018e31 21. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:4304: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000014042fa7 22. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5605: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000014013749 23. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000140127f9 24. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000014011fce 25. /build/src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000001406ce8a 26. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000014973b42 27. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000001497268d 28. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000014974d24 29. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001492924b 30. /build/src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88641 31. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 2025.07.28 11:51:22.555032 [ 5327 ] {d06702db-c1f7-4d80-8a64-843633280add} executeQuery: Code: 407. DB::Exception: Intermediate result overflow (signed a = -9223372036854775808, signed b = -1, min = -9223372036854775808, max = 9223372036854775807): In scope SELECT gcd(9223372036854775808, -1). (DECIMAL_OVERFLOW) (version 25.3.6.10636.altinitytest (altinity build)) (from [::1]:47030) (comment: 01666_gcd_ubsan.sql) (query 5, line 6) (in query: SELECT gcd(9223372036854775808, -1);), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, long&, long&, long&, long&) @ 0x000000000ba4130b 4. /build/src/Functions/GCDLCMImpl.h:44: long DB::GCDLCMImpl, DB::(anonymous namespace)::GCDImpl::NameGCD>::apply(unsigned long, DB::(anonymous namespace)) @ 0x000000000b9c72d5 5. /build/src/Functions/FunctionBinaryArithmetic.h:309: _ZN2DBL16castTypeToEitherIJNS_14DataTypeNumberIDuEENS1_ItEENS1_IjEENS1_ImEENS1_IN4wide7integerILm128EjEEEENS1_INS7_ILm256EjEEEENS1_IDB8_EENS1_IsEENS1_IiEENS1_IlEENS1_INS7_ILm128EiEEEENS1_INS7_ILm256EiEEEENS_15DataTypeDecimalINS_7DecimalIiEEEENSL_INSM_IlEEEENSL_INSM_ISH_EEEENSL_INSM_ISJ_EEEENS_12DataTypeDateENS_16DataTypeDateTimeENS_19DataTypeFixedStringENS_14DataTypeStringENS_16DataTypeIntervalEENS_9IDataTypeEZZNS_24FunctionBinaryArithmeticINS_12_GLOBAL__N_17GCDImplENS12_7NameGCDELb0ELb0ELb0EE13castBothTypesIZNKS15_12executeImpl2ERKNSt3__16vectorINS_21ColumnWithTypeAndNameENS17_9allocatorIS19_EEEERKNS17_10shared_ptrIKS10_EEmPKNS_8PODArrayIDuLm4096E9AllocatorILb0ELb0EELm63ELm64EEEEUlRKT_RKT0_E_EEbPS1G_S1X_OS1Q_ENKUlS1S_E_clIS5_EEDaS1S_EUlS1S_E_EEb8TypeListIJDpT_EEPS1U_OT1_ @ 0x000000000ba03e68 6. /build/src/Functions/FunctionBinaryArithmetic.h:838: DB::FunctionBinaryArithmetic::executeImpl2(std::vector> const&, std::shared_ptr const&, unsigned long, DB::PODArray, 63ul, 64ul> const*) const @ 0x000000000b9ea301 7. /build/src/Functions/FunctionBinaryArithmetic.h:2410: DB::FunctionBinaryArithmetic::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000b9e8c17 8. /build/src/Functions/FunctionBinaryArithmetic.h:2645: DB::FunctionBinaryArithmeticWithConstants::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000b9e7bb4 9. /build/src/Functions/IFunction.h:437: DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000a069f2a 10. /build/src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000012d9965a 11. /build/src/Functions/IFunction.cpp:351: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d93b02 12. /build/src/Functions/IFunction.cpp:420: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d95059 13. /build/src/Functions/IFunction.cpp:498: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d95c72 14. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3567: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000014034494 15. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3838: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000014019a9e 16. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3980: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000014018e31 17. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:4304: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000014042fa7 18. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5605: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000014013749 19. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000140127f9 20. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000014011fce 21. /build/src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000001406ce8a 22. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000014973b42 23. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000001497268d 24. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000014974d24 25. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001492924b 26. /build/src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88641 27. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 28. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 29. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 30. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 31. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 2025.07.28 11:51:22.564896 [ 5327 ] {} TCPHandler: Code: 407. DB::Exception: Intermediate result overflow (signed a = -9223372036854775808, signed b = -1, min = -9223372036854775808, max = 9223372036854775807): In scope SELECT gcd(9223372036854775808, -1). (DECIMAL_OVERFLOW), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, long&, long&, long&, long&) @ 0x000000000ba4130b 4. /build/src/Functions/GCDLCMImpl.h:44: long DB::GCDLCMImpl, DB::(anonymous namespace)::GCDImpl::NameGCD>::apply(unsigned long, DB::(anonymous namespace)) @ 0x000000000b9c72d5 5. /build/src/Functions/FunctionBinaryArithmetic.h:309: _ZN2DBL16castTypeToEitherIJNS_14DataTypeNumberIDuEENS1_ItEENS1_IjEENS1_ImEENS1_IN4wide7integerILm128EjEEEENS1_INS7_ILm256EjEEEENS1_IDB8_EENS1_IsEENS1_IiEENS1_IlEENS1_INS7_ILm128EiEEEENS1_INS7_ILm256EiEEEENS_15DataTypeDecimalINS_7DecimalIiEEEENSL_INSM_IlEEEENSL_INSM_ISH_EEEENSL_INSM_ISJ_EEEENS_12DataTypeDateENS_16DataTypeDateTimeENS_19DataTypeFixedStringENS_14DataTypeStringENS_16DataTypeIntervalEENS_9IDataTypeEZZNS_24FunctionBinaryArithmeticINS_12_GLOBAL__N_17GCDImplENS12_7NameGCDELb0ELb0ELb0EE13castBothTypesIZNKS15_12executeImpl2ERKNSt3__16vectorINS_21ColumnWithTypeAndNameENS17_9allocatorIS19_EEEERKNS17_10shared_ptrIKS10_EEmPKNS_8PODArrayIDuLm4096E9AllocatorILb0ELb0EELm63ELm64EEEEUlRKT_RKT0_E_EEbPS1G_S1X_OS1Q_ENKUlS1S_E_clIS5_EEDaS1S_EUlS1S_E_EEb8TypeListIJDpT_EEPS1U_OT1_ @ 0x000000000ba03e68 6. /build/src/Functions/FunctionBinaryArithmetic.h:838: DB::FunctionBinaryArithmetic::executeImpl2(std::vector> const&, std::shared_ptr const&, unsigned long, DB::PODArray, 63ul, 64ul> const*) const @ 0x000000000b9ea301 7. /build/src/Functions/FunctionBinaryArithmetic.h:2410: DB::FunctionBinaryArithmetic::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000b9e8c17 8. /build/src/Functions/FunctionBinaryArithmetic.h:2645: DB::FunctionBinaryArithmeticWithConstants::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000b9e7bb4 9. /build/src/Functions/IFunction.h:437: DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000a069f2a 10. /build/src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000012d9965a 11. /build/src/Functions/IFunction.cpp:351: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d93b02 12. /build/src/Functions/IFunction.cpp:420: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d95059 13. /build/src/Functions/IFunction.cpp:498: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d95c72 14. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3567: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000014034494 15. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3838: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000014019a9e 16. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3980: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000014018e31 17. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:4304: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000014042fa7 18. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5605: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000014013749 19. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000140127f9 20. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000014011fce 21. /build/src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000001406ce8a 22. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000014973b42 23. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000001497268d 24. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000014974d24 25. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001492924b 26. /build/src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88641 27. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 28. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 29. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 30. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 31. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 2025.07.28 11:51:22.662481 [ 11826 ] {7f3617c8-72aa-4cee-a222-61a7f41e5a77} 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.6.10636.altinitytest (altinity build)) (from [::1]:50820) (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. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type>, char const* const&) @ 0x000000000a093dab 4. /build/src/DataTypes/DataTypesDecimal.cpp:293: void DB::convertToDecimalImpl, DB::DataTypeDecimal>>, void>(T::FieldType const&, unsigned int, T0::FieldType&) @ 0x0000000013c315c8 5. /build/src/DataTypes/DataTypesDecimal.cpp:326: T0::FieldType DB::convertToDecimal, DB::DataTypeDecimal>>>(T::FieldType const&, unsigned int) @ 0x0000000013c3384e 6. /build/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) @ 0x000000001313d274 7. /build/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 @ 0x000000001312f604 8. /build/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&&) @ 0x0000000012fad839 9. /build/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 @ 0x0000000012fd0bce 10. /build/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 @ 0x0000000012fd03fa 11. /build/src/Functions/IFunction.h:437: DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000a069f2a 12. /build/src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000012d9965a 13. /build/src/Functions/IFunction.cpp:351: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d93b02 14. /build/src/Functions/IFunction.cpp:177: DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d93698 15. /build/src/Functions/IFunction.cpp:343: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d93aad 16. /build/src/Functions/IFunction.cpp:420: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d95059 17. /build/src/Functions/IFunction.cpp:498: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d95c72 18. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3567: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000014034494 19. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3838: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000014019a9e 20. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3980: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000014018e31 21. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:4304: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000014042fa7 22. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5605: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000014013749 23. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000140127f9 24. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000014011fce 25. /build/src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000001406ce8a 26. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000014973b42 27. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000001497268d 28. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000014974d24 29. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001492924b 30. /build/src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88641 31. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 2025.07.28 11:51:22.669880 [ 11826 ] {} 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. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type>, char const* const&) @ 0x000000000a093dab 4. /build/src/DataTypes/DataTypesDecimal.cpp:293: void DB::convertToDecimalImpl, DB::DataTypeDecimal>>, void>(T::FieldType const&, unsigned int, T0::FieldType&) @ 0x0000000013c315c8 5. /build/src/DataTypes/DataTypesDecimal.cpp:326: T0::FieldType DB::convertToDecimal, DB::DataTypeDecimal>>>(T::FieldType const&, unsigned int) @ 0x0000000013c3384e 6. /build/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) @ 0x000000001313d274 7. /build/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 @ 0x000000001312f604 8. /build/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&&) @ 0x0000000012fad839 9. /build/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 @ 0x0000000012fd0bce 10. /build/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 @ 0x0000000012fd03fa 11. /build/src/Functions/IFunction.h:437: DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000a069f2a 12. /build/src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000012d9965a 13. /build/src/Functions/IFunction.cpp:351: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d93b02 14. /build/src/Functions/IFunction.cpp:177: DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d93698 15. /build/src/Functions/IFunction.cpp:343: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d93aad 16. /build/src/Functions/IFunction.cpp:420: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d95059 17. /build/src/Functions/IFunction.cpp:498: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d95c72 18. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3567: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000014034494 19. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3838: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000014019a9e 20. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3980: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000014018e31 21. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:4304: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000014042fa7 22. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5605: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000014013749 23. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000140127f9 24. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000014011fce 25. /build/src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000001406ce8a 26. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000014973b42 27. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000001497268d 28. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000014974d24 29. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001492924b 30. /build/src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88641 31. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 2025.07.28 11:51:22.724432 [ 5327 ] {11c4d241-3c02-4e2c-9fb2-b7320026b965} executeQuery: Code: 43. DB::Exception: Illegal types Float64 and Float64 of arguments of function lcm: In scope SELECT lcm(-1.7014118346046923e38, -1.7014118346046923e38). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.6.10636.altinitytest (altinity build)) (from [::1]:47030) (comment: 01666_gcd_ubsan.sql) (query 6, line 7) (in query: SELECT lcm(-170141183460469231731687303715884105728, -170141183460469231731687303715884105728);), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&) @ 0x000000000a10182b 4. /build/src/Functions/FunctionBinaryArithmetic.h:1931: DB::FunctionBinaryArithmetic::getReturnTypeImplStatic(std::vector, std::allocator>> const&, std::shared_ptr) @ 0x000000000c892213 5. /build/src/Functions/IFunction.h:369: DB::IFunctionOverloadResolver::getReturnTypeImpl(std::vector> const&) const @ 0x000000000a6646de 6. /build/src/Functions/IFunction.cpp:645: DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x0000000012d96b0c 7. /build/src/Functions/IFunction.cpp:577: DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x0000000012d9669c 8. /build/src/Functions/IFunction.cpp:606: DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x0000000012d96edc 9. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3544: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000014033cc9 10. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3838: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000014019a9e 11. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3980: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000014018e31 12. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:4304: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000014042fa7 13. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5605: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000014013749 14. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000140127f9 15. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000014011fce 16. /build/src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000001406ce8a 17. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000014973b42 18. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000001497268d 19. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000014974d24 20. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001492924b 21. /build/src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88641 22. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 23. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 24. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 25. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 26. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 27. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 28. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 29. ? @ 0x00007fbc6213eac3 30. ? @ 0x00007fbc621d0850 2025.07.28 11:51:22.730068 [ 5327 ] {} TCPHandler: Code: 43. DB::Exception: Illegal types Float64 and Float64 of arguments of function lcm: In scope SELECT lcm(-1.7014118346046923e38, -1.7014118346046923e38). (ILLEGAL_TYPE_OF_ARGUMENT), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&) @ 0x000000000a10182b 4. /build/src/Functions/FunctionBinaryArithmetic.h:1931: DB::FunctionBinaryArithmetic::getReturnTypeImplStatic(std::vector, std::allocator>> const&, std::shared_ptr) @ 0x000000000c892213 5. /build/src/Functions/IFunction.h:369: DB::IFunctionOverloadResolver::getReturnTypeImpl(std::vector> const&) const @ 0x000000000a6646de 6. /build/src/Functions/IFunction.cpp:645: DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x0000000012d96b0c 7. /build/src/Functions/IFunction.cpp:577: DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x0000000012d9669c 8. /build/src/Functions/IFunction.cpp:606: DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x0000000012d96edc 9. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3544: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000014033cc9 10. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3838: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000014019a9e 11. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3980: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000014018e31 12. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:4304: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000014042fa7 13. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5605: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000014013749 14. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000140127f9 15. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000014011fce 16. /build/src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000001406ce8a 17. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000014973b42 18. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000001497268d 19. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000014974d24 20. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001492924b 21. /build/src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88641 22. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 23. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 24. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 25. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 26. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 27. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 28. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 29. ? @ 0x00007fbc6213eac3 30. ? @ 0x00007fbc621d0850 2025.07.28 11:51:22.762848 [ 11826 ] {0eb70680-3b5e-44ee-b3c8-502d762a0248} 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.6.10636.altinitytest (altinity build)) (from [::1]:50820) (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. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type>, char const* const&) @ 0x000000000a093dab 4. /build/src/DataTypes/DataTypesDecimal.cpp:293: void DB::convertToDecimalImpl, DB::DataTypeDecimal>, void>(T::FieldType const&, unsigned int, T0::FieldType&) @ 0x0000000013c30935 5. /build/src/DataTypes/DataTypesDecimal.cpp:326: T0::FieldType DB::convertToDecimal, DB::DataTypeDecimal>>(T::FieldType const&, unsigned int) @ 0x0000000013c32d8b 6. /build/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) @ 0x000000001310bf94 7. /build/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 @ 0x00000000130fe884 8. /build/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&&) @ 0x0000000012fad239 9. /build/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 @ 0x0000000012fce44e 10. /build/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 @ 0x0000000012fcdc7a 11. /build/src/Functions/IFunction.h:437: DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000a069f2a 12. /build/src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000012d9965a 13. /build/src/Functions/IFunction.cpp:351: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d93b02 14. /build/src/Functions/IFunction.cpp:177: DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d93698 15. /build/src/Functions/IFunction.cpp:343: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d93aad 16. /build/src/Functions/IFunction.cpp:420: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d95059 17. /build/src/Functions/IFunction.cpp:498: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d95c72 18. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3567: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000014034494 19. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3838: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000014019a9e 20. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3980: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000014018e31 21. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:4304: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000014042fa7 22. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5605: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000014013749 23. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000140127f9 24. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000014011fce 25. /build/src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000001406ce8a 26. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000014973b42 27. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000001497268d 28. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000014974d24 29. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001492924b 30. /build/src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88641 31. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 2025.07.28 11:51:22.767161 [ 11826 ] {} 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. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type>, char const* const&) @ 0x000000000a093dab 4. /build/src/DataTypes/DataTypesDecimal.cpp:293: void DB::convertToDecimalImpl, DB::DataTypeDecimal>, void>(T::FieldType const&, unsigned int, T0::FieldType&) @ 0x0000000013c30935 5. /build/src/DataTypes/DataTypesDecimal.cpp:326: T0::FieldType DB::convertToDecimal, DB::DataTypeDecimal>>(T::FieldType const&, unsigned int) @ 0x0000000013c32d8b 6. /build/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) @ 0x000000001310bf94 7. /build/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 @ 0x00000000130fe884 8. /build/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&&) @ 0x0000000012fad239 9. /build/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 @ 0x0000000012fce44e 10. /build/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 @ 0x0000000012fcdc7a 11. /build/src/Functions/IFunction.h:437: DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000a069f2a 12. /build/src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000012d9965a 13. /build/src/Functions/IFunction.cpp:351: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d93b02 14. /build/src/Functions/IFunction.cpp:177: DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d93698 15. /build/src/Functions/IFunction.cpp:343: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d93aad 16. /build/src/Functions/IFunction.cpp:420: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d95059 17. /build/src/Functions/IFunction.cpp:498: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d95c72 18. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3567: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000014034494 19. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3838: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000014019a9e 20. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3980: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000014018e31 21. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:4304: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000014042fa7 22. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5605: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000014013749 23. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000140127f9 24. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000014011fce 25. /build/src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000001406ce8a 26. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000014973b42 27. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000001497268d 28. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000014974d24 29. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001492924b 30. /build/src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88641 31. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 2025.07.28 11:51:22.894434 [ 11826 ] {3477a15b-b8a4-4821-8bac-63bb7fbdddae} 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.6.10636.altinitytest (altinity build)) (from [::1]:50820) (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. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type>, char const* const&) @ 0x000000000a093dab 4. /build/src/DataTypes/DataTypesDecimal.cpp:293: void DB::convertToDecimalImpl, DB::DataTypeDecimal>, void>(T::FieldType const&, unsigned int, T0::FieldType&) @ 0x0000000013c30bf6 5. /build/src/DataTypes/DataTypesDecimal.cpp:326: T0::FieldType DB::convertToDecimal, DB::DataTypeDecimal>>(T::FieldType const&, unsigned int) @ 0x0000000013c331e9 6. /build/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) @ 0x00000000131246b5 7. /build/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 @ 0x0000000013116fa4 8. /build/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&&) @ 0x0000000012fad539 9. /build/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 @ 0x0000000012fcf80e 10. /build/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 @ 0x0000000012fcf03a 11. /build/src/Functions/IFunction.h:437: DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000a069f2a 12. /build/src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000012d9965a 13. /build/src/Functions/IFunction.cpp:351: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d93b02 14. /build/src/Functions/IFunction.cpp:177: DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d93698 15. /build/src/Functions/IFunction.cpp:343: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d93aad 16. /build/src/Functions/IFunction.cpp:420: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d95059 17. /build/src/Functions/IFunction.cpp:498: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d95c72 18. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3567: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000014034494 19. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3838: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000014019a9e 20. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3980: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000014018e31 21. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:4304: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000014042fa7 22. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5605: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000014013749 23. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000140127f9 24. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000014011fce 25. /build/src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000001406ce8a 26. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000014973b42 27. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000001497268d 28. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000014974d24 29. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001492924b 30. /build/src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88641 31. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 2025.07.28 11:51:22.906568 [ 11826 ] {} 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. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type>, char const* const&) @ 0x000000000a093dab 4. /build/src/DataTypes/DataTypesDecimal.cpp:293: void DB::convertToDecimalImpl, DB::DataTypeDecimal>, void>(T::FieldType const&, unsigned int, T0::FieldType&) @ 0x0000000013c30bf6 5. /build/src/DataTypes/DataTypesDecimal.cpp:326: T0::FieldType DB::convertToDecimal, DB::DataTypeDecimal>>(T::FieldType const&, unsigned int) @ 0x0000000013c331e9 6. /build/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) @ 0x00000000131246b5 7. /build/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 @ 0x0000000013116fa4 8. /build/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&&) @ 0x0000000012fad539 9. /build/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 @ 0x0000000012fcf80e 10. /build/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 @ 0x0000000012fcf03a 11. /build/src/Functions/IFunction.h:437: DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000a069f2a 12. /build/src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000012d9965a 13. /build/src/Functions/IFunction.cpp:351: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d93b02 14. /build/src/Functions/IFunction.cpp:177: DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d93698 15. /build/src/Functions/IFunction.cpp:343: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d93aad 16. /build/src/Functions/IFunction.cpp:420: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d95059 17. /build/src/Functions/IFunction.cpp:498: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d95c72 18. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3567: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000014034494 19. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3838: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000014019a9e 20. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3980: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000014018e31 21. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:4304: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000014042fa7 22. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5605: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000014013749 23. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000140127f9 24. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000014011fce 25. /build/src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000001406ce8a 26. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000014973b42 27. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000001497268d 28. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000014974d24 29. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001492924b 30. /build/src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88641 31. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 2025.07.28 11:51:23.035161 [ 12807 ] {799fb577-b837-4363-93de-4f961fa47dee} executeQuery: Code: 48. DB::Exception: Truncate is not supported by storage Null. (NOT_IMPLEMENTED) (version 25.3.6.10636.altinitytest (altinity build)) (from [::1]:47098) (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. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x000000000a06b56b 4. /build/src/Storages/IStorage.cpp:171: DB::IStorage::truncate(std::shared_ptr const&, std::shared_ptr const&, std::shared_ptr, DB::TableExclusiveLockHolder&) @ 0x0000000015d1ec7a 5. /build/src/Interpreters/InterpreterDropQuery.cpp:282: DB::InterpreterDropQuery::executeToTableImpl(std::shared_ptr const&, DB::ASTDropQuery&, std::shared_ptr&, StrongTypedef, DB::UUIDTag>&) @ 0x0000000014915304 6. /build/src/Interpreters/InterpreterDropQuery.cpp:118: DB::InterpreterDropQuery::executeToTable(DB::ASTDropQuery&) @ 0x00000000149137b4 7. /build/src/Interpreters/InterpreterDropQuery.cpp:91: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000014912f07 8. /build/src/Interpreters/InterpreterDropQuery.cpp:72: DB::InterpreterDropQuery::execute() @ 0x0000000014912b65 9. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88dc9 10. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 11. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 12. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 13. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 14. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 16. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 17. ? @ 0x00007fbc6213eac3 18. ? @ 0x00007fbc621d0850 2025.07.28 11:51:23.047398 [ 11826 ] {8742ea5f-b985-433d-bbb2-000acac32386} 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.6.10636.altinitytest (altinity build)) (from [::1]:50820) (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. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type>, char const* const&) @ 0x000000000a093dab 4. /build/src/DataTypes/DataTypesDecimal.cpp:293: void DB::convertToDecimalImpl, DB::DataTypeDecimal>>, void>(T::FieldType const&, unsigned int, T0::FieldType&) @ 0x0000000013c315c8 5. /build/src/DataTypes/DataTypesDecimal.cpp:326: T0::FieldType DB::convertToDecimal, DB::DataTypeDecimal>>>(T::FieldType const&, unsigned int) @ 0x0000000013c3384e 6. /build/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) @ 0x000000001313d274 7. /build/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 @ 0x000000001312f604 8. /build/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&&) @ 0x0000000012fad839 9. /build/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 @ 0x0000000012fd0bce 10. /build/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 @ 0x0000000012fd03fa 11. /build/src/Functions/IFunction.h:437: DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000a069f2a 12. /build/src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000012d9965a 13. /build/src/Functions/IFunction.cpp:351: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d93b02 14. /build/src/Functions/IFunction.cpp:177: DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d93698 15. /build/src/Functions/IFunction.cpp:343: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d93aad 16. /build/src/Functions/IFunction.cpp:420: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d95059 17. /build/src/Functions/IFunction.cpp:498: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d95c72 18. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3567: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000014034494 19. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3838: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000014019a9e 20. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3980: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000014018e31 21. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:4304: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000014042fa7 22. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5605: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000014013749 23. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000140127f9 24. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000014011fce 25. /build/src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000001406ce8a 26. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000014973b42 27. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000001497268d 28. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000014974d24 29. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001492924b 30. /build/src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88641 31. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 2025.07.28 11:51:23.066492 [ 12807 ] {} 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. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x000000000a06b56b 4. /build/src/Storages/IStorage.cpp:171: DB::IStorage::truncate(std::shared_ptr const&, std::shared_ptr const&, std::shared_ptr, DB::TableExclusiveLockHolder&) @ 0x0000000015d1ec7a 5. /build/src/Interpreters/InterpreterDropQuery.cpp:282: DB::InterpreterDropQuery::executeToTableImpl(std::shared_ptr const&, DB::ASTDropQuery&, std::shared_ptr&, StrongTypedef, DB::UUIDTag>&) @ 0x0000000014915304 6. /build/src/Interpreters/InterpreterDropQuery.cpp:118: DB::InterpreterDropQuery::executeToTable(DB::ASTDropQuery&) @ 0x00000000149137b4 7. /build/src/Interpreters/InterpreterDropQuery.cpp:91: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000014912f07 8. /build/src/Interpreters/InterpreterDropQuery.cpp:72: DB::InterpreterDropQuery::execute() @ 0x0000000014912b65 9. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88dc9 10. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 11. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 12. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 13. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 14. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 16. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 17. ? @ 0x00007fbc6213eac3 18. ? @ 0x00007fbc621d0850 2025.07.28 11:51:23.067280 [ 11826 ] {} 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. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type>, char const* const&) @ 0x000000000a093dab 4. /build/src/DataTypes/DataTypesDecimal.cpp:293: void DB::convertToDecimalImpl, DB::DataTypeDecimal>>, void>(T::FieldType const&, unsigned int, T0::FieldType&) @ 0x0000000013c315c8 5. /build/src/DataTypes/DataTypesDecimal.cpp:326: T0::FieldType DB::convertToDecimal, DB::DataTypeDecimal>>>(T::FieldType const&, unsigned int) @ 0x0000000013c3384e 6. /build/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) @ 0x000000001313d274 7. /build/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 @ 0x000000001312f604 8. /build/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&&) @ 0x0000000012fad839 9. /build/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 @ 0x0000000012fd0bce 10. /build/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 @ 0x0000000012fd03fa 11. /build/src/Functions/IFunction.h:437: DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000a069f2a 12. /build/src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000012d9965a 13. /build/src/Functions/IFunction.cpp:351: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d93b02 14. /build/src/Functions/IFunction.cpp:177: DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d93698 15. /build/src/Functions/IFunction.cpp:343: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d93aad 16. /build/src/Functions/IFunction.cpp:420: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d95059 17. /build/src/Functions/IFunction.cpp:498: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d95c72 18. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3567: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000014034494 19. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3838: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000014019a9e 20. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3980: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000014018e31 21. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:4304: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000014042fa7 22. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5605: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000014013749 23. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000140127f9 24. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000014011fce 25. /build/src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000001406ce8a 26. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000014973b42 27. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000001497268d 28. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000014974d24 29. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001492924b 30. /build/src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88641 31. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 2025.07.28 11:51:23.205800 [ 11826 ] {9746fbe1-73af-454e-9cd3-9c79fe5f15a1} 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.6.10636.altinitytest (altinity build)) (from [::1]:50820) (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. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type>, char const* const&) @ 0x000000000a093dab 4. /build/src/DataTypes/DataTypesDecimal.cpp:293: void DB::convertToDecimalImpl, DB::DataTypeDecimal>, void>(T::FieldType const&, unsigned int, T0::FieldType&) @ 0x0000000013c30935 5. /build/src/DataTypes/DataTypesDecimal.cpp:326: T0::FieldType DB::convertToDecimal, DB::DataTypeDecimal>>(T::FieldType const&, unsigned int) @ 0x0000000013c32d8b 6. /build/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) @ 0x000000001310bf94 7. /build/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 @ 0x00000000130fe884 8. /build/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&&) @ 0x0000000012fad239 9. /build/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 @ 0x0000000012fce44e 10. /build/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 @ 0x0000000012fcdc7a 11. /build/src/Functions/IFunction.h:437: DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000a069f2a 12. /build/src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000012d9965a 13. /build/src/Functions/IFunction.cpp:351: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d93b02 14. /build/src/Functions/IFunction.cpp:177: DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d93698 15. /build/src/Functions/IFunction.cpp:343: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d93aad 16. /build/src/Functions/IFunction.cpp:420: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d95059 17. /build/src/Functions/IFunction.cpp:498: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d95c72 18. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3567: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000014034494 19. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3838: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000014019a9e 20. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3980: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000014018e31 21. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:4304: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000014042fa7 22. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5605: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000014013749 23. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000140127f9 24. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000014011fce 25. /build/src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000001406ce8a 26. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000014973b42 27. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000001497268d 28. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000014974d24 29. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001492924b 30. /build/src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88641 31. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 2025.07.28 11:51:23.215636 [ 11826 ] {} 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. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type>, char const* const&) @ 0x000000000a093dab 4. /build/src/DataTypes/DataTypesDecimal.cpp:293: void DB::convertToDecimalImpl, DB::DataTypeDecimal>, void>(T::FieldType const&, unsigned int, T0::FieldType&) @ 0x0000000013c30935 5. /build/src/DataTypes/DataTypesDecimal.cpp:326: T0::FieldType DB::convertToDecimal, DB::DataTypeDecimal>>(T::FieldType const&, unsigned int) @ 0x0000000013c32d8b 6. /build/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) @ 0x000000001310bf94 7. /build/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 @ 0x00000000130fe884 8. /build/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&&) @ 0x0000000012fad239 9. /build/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 @ 0x0000000012fce44e 10. /build/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 @ 0x0000000012fcdc7a 11. /build/src/Functions/IFunction.h:437: DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000a069f2a 12. /build/src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000012d9965a 13. /build/src/Functions/IFunction.cpp:351: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d93b02 14. /build/src/Functions/IFunction.cpp:177: DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d93698 15. /build/src/Functions/IFunction.cpp:343: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d93aad 16. /build/src/Functions/IFunction.cpp:420: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d95059 17. /build/src/Functions/IFunction.cpp:498: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d95c72 18. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3567: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000014034494 19. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3838: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000014019a9e 20. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3980: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000014018e31 21. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:4304: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000014042fa7 22. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5605: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000014013749 23. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000140127f9 24. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000014011fce 25. /build/src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000001406ce8a 26. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000014973b42 27. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000001497268d 28. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000014974d24 29. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001492924b 30. /build/src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88641 31. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 2025.07.28 11:51:23.309059 [ 11826 ] {c86dd172-ab64-4d5c-9613-37cc4cb509ef} 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.6.10636.altinitytest (altinity build)) (from [::1]:50820) (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. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type>, char const* const&) @ 0x000000000a093dab 4. /build/src/DataTypes/DataTypesDecimal.cpp:293: void DB::convertToDecimalImpl, DB::DataTypeDecimal>, void>(T::FieldType const&, unsigned int, T0::FieldType&) @ 0x0000000013c30bf6 5. /build/src/DataTypes/DataTypesDecimal.cpp:326: T0::FieldType DB::convertToDecimal, DB::DataTypeDecimal>>(T::FieldType const&, unsigned int) @ 0x0000000013c331e9 6. /build/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) @ 0x00000000131246b5 7. /build/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 @ 0x0000000013116fa4 8. /build/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&&) @ 0x0000000012fad539 9. /build/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 @ 0x0000000012fcf80e 10. /build/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 @ 0x0000000012fcf03a 11. /build/src/Functions/IFunction.h:437: DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000a069f2a 12. /build/src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000012d9965a 13. /build/src/Functions/IFunction.cpp:351: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d93b02 14. /build/src/Functions/IFunction.cpp:177: DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d93698 15. /build/src/Functions/IFunction.cpp:343: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d93aad 16. /build/src/Functions/IFunction.cpp:420: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d95059 17. /build/src/Functions/IFunction.cpp:498: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d95c72 18. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3567: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000014034494 19. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3838: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000014019a9e 20. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3980: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000014018e31 21. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:4304: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000014042fa7 22. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5605: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000014013749 23. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000140127f9 24. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000014011fce 25. /build/src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000001406ce8a 26. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000014973b42 27. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000001497268d 28. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000014974d24 29. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001492924b 30. /build/src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88641 31. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 2025.07.28 11:51:23.320719 [ 11826 ] {} 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. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type>, char const* const&) @ 0x000000000a093dab 4. /build/src/DataTypes/DataTypesDecimal.cpp:293: void DB::convertToDecimalImpl, DB::DataTypeDecimal>, void>(T::FieldType const&, unsigned int, T0::FieldType&) @ 0x0000000013c30bf6 5. /build/src/DataTypes/DataTypesDecimal.cpp:326: T0::FieldType DB::convertToDecimal, DB::DataTypeDecimal>>(T::FieldType const&, unsigned int) @ 0x0000000013c331e9 6. /build/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) @ 0x00000000131246b5 7. /build/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 @ 0x0000000013116fa4 8. /build/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&&) @ 0x0000000012fad539 9. /build/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 @ 0x0000000012fcf80e 10. /build/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 @ 0x0000000012fcf03a 11. /build/src/Functions/IFunction.h:437: DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000a069f2a 12. /build/src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000012d9965a 13. /build/src/Functions/IFunction.cpp:351: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d93b02 14. /build/src/Functions/IFunction.cpp:177: DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d93698 15. /build/src/Functions/IFunction.cpp:343: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d93aad 16. /build/src/Functions/IFunction.cpp:420: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d95059 17. /build/src/Functions/IFunction.cpp:498: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d95c72 18. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3567: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000014034494 19. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3838: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000014019a9e 20. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3980: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000014018e31 21. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:4304: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000014042fa7 22. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5605: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000014013749 23. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000140127f9 24. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000014011fce 25. /build/src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000001406ce8a 26. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000014973b42 27. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000001497268d 28. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000014974d24 29. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001492924b 30. /build/src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88641 31. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 2025.07.28 11:51:23.427630 [ 11826 ] {257ce85e-bb05-4f7a-a6a9-667736e93658} 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.6.10636.altinitytest (altinity build)) (from [::1]:50820) (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. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type>, char const* const&) @ 0x000000000a093dab 4. /build/src/DataTypes/DataTypesDecimal.cpp:293: void DB::convertToDecimalImpl, DB::DataTypeDecimal>>, void>(T::FieldType const&, unsigned int, T0::FieldType&) @ 0x0000000013c315c8 5. /build/src/DataTypes/DataTypesDecimal.cpp:326: T0::FieldType DB::convertToDecimal, DB::DataTypeDecimal>>>(T::FieldType const&, unsigned int) @ 0x0000000013c3384e 6. /build/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) @ 0x000000001313d274 7. /build/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 @ 0x000000001312f604 8. /build/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&&) @ 0x0000000012fad839 9. /build/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 @ 0x0000000012fd0bce 10. /build/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 @ 0x0000000012fd03fa 11. /build/src/Functions/IFunction.h:437: DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000a069f2a 12. /build/src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000012d9965a 13. /build/src/Functions/IFunction.cpp:351: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d93b02 14. /build/src/Functions/IFunction.cpp:177: DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d93698 15. /build/src/Functions/IFunction.cpp:343: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d93aad 16. /build/src/Functions/IFunction.cpp:420: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d95059 17. /build/src/Functions/IFunction.cpp:498: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d95c72 18. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3567: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000014034494 19. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3838: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000014019a9e 20. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3980: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000014018e31 21. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:4304: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000014042fa7 22. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5605: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000014013749 23. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000140127f9 24. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000014011fce 25. /build/src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000001406ce8a 26. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000014973b42 27. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000001497268d 28. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000014974d24 29. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001492924b 30. /build/src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88641 31. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 2025.07.28 11:51:23.445502 [ 11826 ] {} 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. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type>, char const* const&) @ 0x000000000a093dab 4. /build/src/DataTypes/DataTypesDecimal.cpp:293: void DB::convertToDecimalImpl, DB::DataTypeDecimal>>, void>(T::FieldType const&, unsigned int, T0::FieldType&) @ 0x0000000013c315c8 5. /build/src/DataTypes/DataTypesDecimal.cpp:326: T0::FieldType DB::convertToDecimal, DB::DataTypeDecimal>>>(T::FieldType const&, unsigned int) @ 0x0000000013c3384e 6. /build/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) @ 0x000000001313d274 7. /build/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 @ 0x000000001312f604 8. /build/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&&) @ 0x0000000012fad839 9. /build/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 @ 0x0000000012fd0bce 10. /build/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 @ 0x0000000012fd03fa 11. /build/src/Functions/IFunction.h:437: DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000a069f2a 12. /build/src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000012d9965a 13. /build/src/Functions/IFunction.cpp:351: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d93b02 14. /build/src/Functions/IFunction.cpp:177: DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d93698 15. /build/src/Functions/IFunction.cpp:343: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d93aad 16. /build/src/Functions/IFunction.cpp:420: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d95059 17. /build/src/Functions/IFunction.cpp:498: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d95c72 18. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3567: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000014034494 19. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3838: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000014019a9e 20. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3980: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000014018e31 21. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:4304: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000014042fa7 22. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5605: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000014013749 23. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000140127f9 24. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000014011fce 25. /build/src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000001406ce8a 26. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000014973b42 27. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000001497268d 28. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000014974d24 29. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001492924b 30. /build/src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88641 31. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 2025.07.28 11:51:23.616228 [ 5327 ] {f6db1d16-7b14-47ec-9978-9a7c9b9ca2a6} executeQuery: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION) (version 25.3.6.10636.altinitytest (altinity build)) (from [::1]:47118) (comment: 03010_sum_to_to_count_if_nullable.sql) (query 2, line 3) (in query: SET enable_analyzer = 0;), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x000000000c25bc4b 4. /build/src/Access/SettingsConstraints.cpp:343: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000138596e3 5. /build/src/Access/SettingsConstraints.cpp:300: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000013858faf 6. /build/src/Access/SettingsConstraints.cpp:194: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges const&, DB::SettingSource) const @ 0x00000000138591b3 7. /build/src/Interpreters/Context.cpp:2722: DB::Context::checkSettingsConstraints(DB::SettingsChanges const&, DB::SettingSource) @ 0x0000000014436509 8. /build/src/Interpreters/InterpreterSetQuery.cpp:28: DB::InterpreterSetQuery::execute() @ 0x00000000149e240a 9. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88dc9 10. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 11. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 12. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 13. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 14. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 16. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 17. ? @ 0x00007fbc6213eac3 18. ? @ 0x00007fbc621d0850 2025.07.28 11:51:23.627929 [ 5327 ] {} 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. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x000000000c25bc4b 4. /build/src/Access/SettingsConstraints.cpp:343: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000138596e3 5. /build/src/Access/SettingsConstraints.cpp:300: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000013858faf 6. /build/src/Access/SettingsConstraints.cpp:194: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges const&, DB::SettingSource) const @ 0x00000000138591b3 7. /build/src/Interpreters/Context.cpp:2722: DB::Context::checkSettingsConstraints(DB::SettingsChanges const&, DB::SettingSource) @ 0x0000000014436509 8. /build/src/Interpreters/InterpreterSetQuery.cpp:28: DB::InterpreterSetQuery::execute() @ 0x00000000149e240a 9. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88dc9 10. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 11. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 12. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 13. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 14. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 16. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 17. ? @ 0x00007fbc6213eac3 18. ? @ 0x00007fbc621d0850 2025.07.28 11:51:23.906228 [ 15481 ] {bed3dae0-6d8f-4781-8000-b4ef44bc1220} executeQuery: Code: 636. DB::Exception: The table structure cannot be extracted from a Native format file. Error: Code: 128. DB::Exception: Array sizes are too large: 13830481612736675823. (TOO_LARGE_ARRAY_SIZE) (version 25.3.6.10636.altinitytest (altinity build)). You can specify the structure manually. (CANNOT_EXTRACT_TABLE_STRUCTURE) (version 25.3.6.10636.altinitytest (altinity build)) (from [::1]:47150) (comment: 02426_pod_array_overflow_2.sql) (query 1, line 1) (in query: SELECT * FROM format(Native, 'k0\x23Array(Tuple(FixedString(1), Int64))\0\0\0\0\0\0\0�����\0����������������\0�\0\0\0\0\0\0\0\0\0\0\0\0\0\0\0d\0\0\0\0\0\0\0\0\0\0\0\0\0�1?Vi�%');), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&, String&) @ 0x000000000e65d7ab 4. /build/src/Formats/ReadSchemaUtils.cpp:287: DB::readSchemaFromFormatImpl(std::optional, std::optional const&, DB::IReadBufferIterator&, std::shared_ptr const&) @ 0x000000001697997b 5. /build/src/Formats/ReadSchemaUtils.cpp:548: DB::readSchemaFromFormat(String const&, std::optional const&, DB::IReadBufferIterator&, std::shared_ptr const&) @ 0x000000001697a742 6. /build/src/TableFunctions/TableFunctionFormat.cpp:146: DB::(anonymous namespace)::TableFunctionFormat::executeImpl(std::shared_ptr const&, std::shared_ptr, String const&, DB::ColumnsDescription, bool) const @ 0x000000001185a43d 7. /build/src/TableFunctions/ITableFunction.cpp:36: DB::ITableFunction::execute(std::shared_ptr const&, std::shared_ptr, String const&, DB::ColumnsDescription, bool, bool) const @ 0x00000000131e9fc3 8. /build/src/Interpreters/Context.cpp:2501: DB::Context::executeTableFunction(std::shared_ptr const&, std::shared_ptr const&) @ 0x00000000144345b2 9. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:4975: DB::QueryAnalyzer::resolveTableFunction(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&, bool) @ 0x000000001401e9f9 10. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5342: DB::QueryAnalyzer::resolveQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&) @ 0x00000000140452bf 11. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5597: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000140136f0 12. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000140127f9 13. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000014011fce 14. /build/src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000001406ce8a 15. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000014973b42 16. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000001497268d 17. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000014974d24 18. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001492924b 19. /build/src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88641 20. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 21. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 22. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 23. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 24. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 25. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 26. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 27. ? @ 0x00007fbc6213eac3 28. ? @ 0x00007fbc621d0850 2025.07.28 11:51:23.913115 [ 15481 ] {} TCPHandler: Code: 636. DB::Exception: The table structure cannot be extracted from a Native format file. Error: Code: 128. DB::Exception: Array sizes are too large: 13830481612736675823. (TOO_LARGE_ARRAY_SIZE) (version 25.3.6.10636.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. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&, String&) @ 0x000000000e65d7ab 4. /build/src/Formats/ReadSchemaUtils.cpp:287: DB::readSchemaFromFormatImpl(std::optional, std::optional const&, DB::IReadBufferIterator&, std::shared_ptr const&) @ 0x000000001697997b 5. /build/src/Formats/ReadSchemaUtils.cpp:548: DB::readSchemaFromFormat(String const&, std::optional const&, DB::IReadBufferIterator&, std::shared_ptr const&) @ 0x000000001697a742 6. /build/src/TableFunctions/TableFunctionFormat.cpp:146: DB::(anonymous namespace)::TableFunctionFormat::executeImpl(std::shared_ptr const&, std::shared_ptr, String const&, DB::ColumnsDescription, bool) const @ 0x000000001185a43d 7. /build/src/TableFunctions/ITableFunction.cpp:36: DB::ITableFunction::execute(std::shared_ptr const&, std::shared_ptr, String const&, DB::ColumnsDescription, bool, bool) const @ 0x00000000131e9fc3 8. /build/src/Interpreters/Context.cpp:2501: DB::Context::executeTableFunction(std::shared_ptr const&, std::shared_ptr const&) @ 0x00000000144345b2 9. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:4975: DB::QueryAnalyzer::resolveTableFunction(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&, bool) @ 0x000000001401e9f9 10. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5342: DB::QueryAnalyzer::resolveQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&) @ 0x00000000140452bf 11. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5597: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000140136f0 12. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000140127f9 13. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000014011fce 14. /build/src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000001406ce8a 15. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000014973b42 16. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000001497268d 17. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000014974d24 18. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001492924b 19. /build/src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88641 20. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 21. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 22. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 23. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 24. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 25. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 26. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 27. ? @ 0x00007fbc6213eac3 28. ? @ 0x00007fbc621d0850 2025.07.28 11:51:23.957568 [ 4900 ] {7c204ea1-40a6-402e-be8e-206fabdac9a1} executeQuery: Code: 137. DB::Exception: test_5.id_value_dictionary: unknown dictionary source type: clickhousex. (UNKNOWN_ELEMENT_IN_CONFIG) (version 25.3.6.10636.altinitytest (altinity build)) (from 0.0.0.0:0) (comment: 02918_wrong_dictionary_source.sql) (in query: /* ddl_entry=query-0000000034 */ CREATE DICTIONARY test_5.id_value_dictionary UUID '20a36f7e-4b29-4d85-a3bf-dc93f8fe48de' (`id` UInt64, `value` String) PRIMARY KEY id SOURCE(CLICKHOUSEX(TABLE 'source_table')) LIFETIME(MIN 0 MAX 1000) LAYOUT(FLAT())), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String const&) @ 0x000000000a07198b 4. /build/src/Dictionaries/DictionarySourceFactory.cpp:116: DB::DictionarySourceFactory::checkSourceAvailable(String const&, String const&, std::shared_ptr const&) const @ 0x0000000012d8cb7d 5. /build/src/Dictionaries/getDictionaryConfigurationFromAST.cpp:539: DB::getDictionaryConfigurationFromAST(DB::ASTCreateQuery const&, std::shared_ptr, String const&) @ 0x0000000013d4829b 6. /build/src/Storages/StorageDictionary.cpp:351: std::shared_ptr std::__function::__policy_invoker (DB::StorageFactory::Arguments const&)>::__call_impl[abi:se190107] (DB::StorageFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::StorageFactory::Arguments const&) @ 0x0000000015d5a661 7. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000015d81ea2 8. /build/src/Interpreters/InterpreterCreateQuery.cpp:1945: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x00000000149009bb 9. /build/src/Interpreters/InterpreterCreateQuery.cpp:1743: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000148f9aa9 10. /build/src/Interpreters/InterpreterCreateQuery.cpp:2352: DB::InterpreterCreateQuery::execute() @ 0x0000000014905a41 11. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88dc9 12. /build/src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x0000000014c8ca7b 13. /build/src/Interpreters/DDLWorker.cpp:510: DB::DDLWorker::tryExecuteQuery(DB::DDLTaskBase&, std::shared_ptr const&, bool) @ 0x00000000144dab9e 14. /build/src/Interpreters/DDLWorker.cpp:675: DB::DDLWorker::processTask(DB::DDLTaskBase&, std::shared_ptr const&, bool) @ 0x00000000144d8ffe 15. /build/src/Databases/DatabaseReplicatedWorker.cpp:372: DB::DatabaseReplicatedDDLWorker::tryEnqueueAndExecuteEntry(DB::DDLLogEntry&, std::shared_ptr, bool) @ 0x0000000013dc29ab 16. /build/src/Databases/DatabaseReplicated.cpp:1139: DB::DatabaseReplicated::tryEnqueueReplicatedDDL(std::shared_ptr const&, std::shared_ptr, DB::QueryFlags) @ 0x0000000013d9f73c 17. /build/src/Interpreters/InterpreterCreateQuery.cpp:1723: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000148f96f8 18. /build/src/Interpreters/InterpreterCreateQuery.cpp:2352: DB::InterpreterCreateQuery::execute() @ 0x0000000014905a41 19. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88dc9 20. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 21. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 22. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 23. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 24. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 25. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 26. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 27. ? @ 0x00007fbc6213eac3 28. ? @ 0x00007fbc621d0850 2025.07.28 11:51:24.030879 [ 4900 ] {7c204ea1-40a6-402e-be8e-206fabdac9a1} executeQuery: Code: 137. DB::Exception: test_5.id_value_dictionary: unknown dictionary source type: clickhousex. (UNKNOWN_ELEMENT_IN_CONFIG) (version 25.3.6.10636.altinitytest (altinity build)) (from [::1]:47078) (comment: 02918_wrong_dictionary_source.sql) (query 4, line 6) (in query: -- There is no "CLICKHOUSEX" dictionary source, so the next query must fail even if `dictionaries_lazy_load` is enabled. CREATE DICTIONARY id_value_dictionary(id UInt64, value String) PRIMARY KEY id SOURCE(CLICKHOUSEX(TABLE 'source_table')) LIFETIME(MIN 0 MAX 1000) LAYOUT(FLAT());), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String const&) @ 0x000000000a07198b 4. /build/src/Dictionaries/DictionarySourceFactory.cpp:116: DB::DictionarySourceFactory::checkSourceAvailable(String const&, String const&, std::shared_ptr const&) const @ 0x0000000012d8cb7d 5. /build/src/Dictionaries/getDictionaryConfigurationFromAST.cpp:539: DB::getDictionaryConfigurationFromAST(DB::ASTCreateQuery const&, std::shared_ptr, String const&) @ 0x0000000013d4829b 6. /build/src/Storages/StorageDictionary.cpp:351: std::shared_ptr std::__function::__policy_invoker (DB::StorageFactory::Arguments const&)>::__call_impl[abi:se190107] (DB::StorageFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::StorageFactory::Arguments const&) @ 0x0000000015d5a661 7. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000015d81ea2 8. /build/src/Interpreters/InterpreterCreateQuery.cpp:1945: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x00000000149009bb 9. /build/src/Interpreters/InterpreterCreateQuery.cpp:1743: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000148f9aa9 10. /build/src/Interpreters/InterpreterCreateQuery.cpp:2352: DB::InterpreterCreateQuery::execute() @ 0x0000000014905a41 11. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88dc9 12. /build/src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x0000000014c8ca7b 13. /build/src/Interpreters/DDLWorker.cpp:510: DB::DDLWorker::tryExecuteQuery(DB::DDLTaskBase&, std::shared_ptr const&, bool) @ 0x00000000144dab9e 14. /build/src/Interpreters/DDLWorker.cpp:675: DB::DDLWorker::processTask(DB::DDLTaskBase&, std::shared_ptr const&, bool) @ 0x00000000144d8ffe 15. /build/src/Databases/DatabaseReplicatedWorker.cpp:372: DB::DatabaseReplicatedDDLWorker::tryEnqueueAndExecuteEntry(DB::DDLLogEntry&, std::shared_ptr, bool) @ 0x0000000013dc29ab 16. /build/src/Databases/DatabaseReplicated.cpp:1139: DB::DatabaseReplicated::tryEnqueueReplicatedDDL(std::shared_ptr const&, std::shared_ptr, DB::QueryFlags) @ 0x0000000013d9f73c 17. /build/src/Interpreters/InterpreterCreateQuery.cpp:1723: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000148f96f8 18. /build/src/Interpreters/InterpreterCreateQuery.cpp:2352: DB::InterpreterCreateQuery::execute() @ 0x0000000014905a41 19. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88dc9 20. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 21. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 22. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 23. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 24. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 25. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 26. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 27. ? @ 0x00007fbc6213eac3 28. ? @ 0x00007fbc621d0850 2025.07.28 11:51:24.113423 [ 4900 ] {} TCPHandler: Code: 137. DB::Exception: test_5.id_value_dictionary: unknown dictionary source type: clickhousex. (UNKNOWN_ELEMENT_IN_CONFIG), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String const&) @ 0x000000000a07198b 4. /build/src/Dictionaries/DictionarySourceFactory.cpp:116: DB::DictionarySourceFactory::checkSourceAvailable(String const&, String const&, std::shared_ptr const&) const @ 0x0000000012d8cb7d 5. /build/src/Dictionaries/getDictionaryConfigurationFromAST.cpp:539: DB::getDictionaryConfigurationFromAST(DB::ASTCreateQuery const&, std::shared_ptr, String const&) @ 0x0000000013d4829b 6. /build/src/Storages/StorageDictionary.cpp:351: std::shared_ptr std::__function::__policy_invoker (DB::StorageFactory::Arguments const&)>::__call_impl[abi:se190107] (DB::StorageFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::StorageFactory::Arguments const&) @ 0x0000000015d5a661 7. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000015d81ea2 8. /build/src/Interpreters/InterpreterCreateQuery.cpp:1945: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x00000000149009bb 9. /build/src/Interpreters/InterpreterCreateQuery.cpp:1743: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000148f9aa9 10. /build/src/Interpreters/InterpreterCreateQuery.cpp:2352: DB::InterpreterCreateQuery::execute() @ 0x0000000014905a41 11. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88dc9 12. /build/src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x0000000014c8ca7b 13. /build/src/Interpreters/DDLWorker.cpp:510: DB::DDLWorker::tryExecuteQuery(DB::DDLTaskBase&, std::shared_ptr const&, bool) @ 0x00000000144dab9e 14. /build/src/Interpreters/DDLWorker.cpp:675: DB::DDLWorker::processTask(DB::DDLTaskBase&, std::shared_ptr const&, bool) @ 0x00000000144d8ffe 15. /build/src/Databases/DatabaseReplicatedWorker.cpp:372: DB::DatabaseReplicatedDDLWorker::tryEnqueueAndExecuteEntry(DB::DDLLogEntry&, std::shared_ptr, bool) @ 0x0000000013dc29ab 16. /build/src/Databases/DatabaseReplicated.cpp:1139: DB::DatabaseReplicated::tryEnqueueReplicatedDDL(std::shared_ptr const&, std::shared_ptr, DB::QueryFlags) @ 0x0000000013d9f73c 17. /build/src/Interpreters/InterpreterCreateQuery.cpp:1723: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000148f96f8 18. /build/src/Interpreters/InterpreterCreateQuery.cpp:2352: DB::InterpreterCreateQuery::execute() @ 0x0000000014905a41 19. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88dc9 20. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 21. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 22. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 23. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 24. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 25. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 26. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 27. ? @ 0x00007fbc6213eac3 28. ? @ 0x00007fbc621d0850 2025.07.28 11:51:24.385150 [ 3287 ] {2c47eaf1-4f2c-442f-a31e-7e5d7eb28f63} executeQuery: Code: 57. DB::Exception: Table test_9.test already exists. (TABLE_ALREADY_EXISTS) (version 25.3.6.10636.altinitytest (altinity build)) (from [::1]:37862) (comment: 03272_json_to_json_alter.gen.sql) (query 50, line 65) (in query: create table test (id UInt64, json JSON(max_dynamic_paths=4)) engine=Memory;), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000a06a8eb 4. /build/src/Interpreters/InterpreterCreateQuery.cpp:1824: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x0000000014901d53 5. /build/src/Interpreters/InterpreterCreateQuery.cpp:1743: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000148f9aa9 6. /build/src/Interpreters/InterpreterCreateQuery.cpp:2352: DB::InterpreterCreateQuery::execute() @ 0x0000000014905a41 7. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88dc9 8. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 9. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 10. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 11. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 12. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 13. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 14. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 15. ? @ 0x00007fbc6213eac3 16. ? @ 0x00007fbc621d0850 2025.07.28 11:51:24.401461 [ 3287 ] {} 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. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000a06a8eb 4. /build/src/Interpreters/InterpreterCreateQuery.cpp:1824: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x0000000014901d53 5. /build/src/Interpreters/InterpreterCreateQuery.cpp:1743: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000148f9aa9 6. /build/src/Interpreters/InterpreterCreateQuery.cpp:2352: DB::InterpreterCreateQuery::execute() @ 0x0000000014905a41 7. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88dc9 8. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 9. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 10. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 11. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 12. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 13. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 14. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 15. ? @ 0x00007fbc6213eac3 16. ? @ 0x00007fbc621d0850 2025.07.28 11:51:24.419164 [ 7630 ] {e99427b9-4bf7-4cf3-a4d8-c2dc731640d1} 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.6.10636.altinitytest (altinity build)) (from [::1]:47164) (comment: 00753_comment_columns_zookeeper.sql) (query 2, line 5) (in query: CREATE TABLE check_comments ( column_name1 UInt8 DEFAULT 1 COMMENT 'comment', column_name2 UInt8 COMMENT 'non default comment' ) ENGINE = ReplicatedMergeTree('/clickhouse/tables/{database}/test_00753/comments', 'r1') ORDER BY column_name1;), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000000a074fcb 4. /build/src/Databases/DatabaseReplicated.cpp:959: DB::DatabaseReplicated::checkTableEngine(DB::ASTCreateQuery const&, DB::ASTStorage&, std::shared_ptr) const @ 0x0000000013d9cf56 5. /build/src/Databases/DatabaseReplicated.cpp:1083: DB::DatabaseReplicated::checkQueryValid(std::shared_ptr const&, std::shared_ptr) const @ 0x0000000013d9ebb5 6. /build/src/Databases/DatabaseReplicated.cpp:1130: DB::DatabaseReplicated::tryEnqueueReplicatedDDL(std::shared_ptr const&, std::shared_ptr, DB::QueryFlags) @ 0x0000000013d9f10b 7. /build/src/Interpreters/InterpreterCreateQuery.cpp:1723: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000148f96f8 8. /build/src/Interpreters/InterpreterCreateQuery.cpp:2352: DB::InterpreterCreateQuery::execute() @ 0x0000000014905a41 9. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88dc9 10. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 11. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 12. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 13. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 14. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 16. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 17. ? @ 0x00007fbc6213eac3 18. ? @ 0x00007fbc621d0850 2025.07.28 11:51:24.452507 [ 7630 ] {} 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. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000000a074fcb 4. /build/src/Databases/DatabaseReplicated.cpp:959: DB::DatabaseReplicated::checkTableEngine(DB::ASTCreateQuery const&, DB::ASTStorage&, std::shared_ptr) const @ 0x0000000013d9cf56 5. /build/src/Databases/DatabaseReplicated.cpp:1083: DB::DatabaseReplicated::checkQueryValid(std::shared_ptr const&, std::shared_ptr) const @ 0x0000000013d9ebb5 6. /build/src/Databases/DatabaseReplicated.cpp:1130: DB::DatabaseReplicated::tryEnqueueReplicatedDDL(std::shared_ptr const&, std::shared_ptr, DB::QueryFlags) @ 0x0000000013d9f10b 7. /build/src/Interpreters/InterpreterCreateQuery.cpp:1723: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000148f96f8 8. /build/src/Interpreters/InterpreterCreateQuery.cpp:2352: DB::InterpreterCreateQuery::execute() @ 0x0000000014905a41 9. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88dc9 10. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 11. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 12. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 13. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 14. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 16. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 17. ? @ 0x00007fbc6213eac3 18. ? @ 0x00007fbc621d0850 2025.07.28 11:51:25.330341 [ 7630 ] {14457d96-d9e4-4eba-b094-a7e09e6df768} executeQuery: Code: 469. DB::Exception: Constraint `c1` for table test_13.t0 (bdb51fc0-4143-4bd0-85e0-e7d2a63cbd6d) is violated at row 1. Expression: (c0 > 5). Column values: c0 = 3. (VIOLATED_CONSTRAINT) (version 25.3.6.10636.altinitytest (altinity build)) (from [::1]:47194) (comment: 03262_udf_in_constraint.sh) (query 5, line 6) (in query: INSERT INTO t0(c0) VALUES ), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.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&) @ 0x0000000013cd2239 4. /build/src/Processors/Transforms/CheckConstraintsTransform.cpp:119: DB::CheckConstraintsTransform::onConsume(DB::Chunk) @ 0x0000000016bfc0bc 5. /build/src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: void std::__function::__policy_invoker::__call_impl[abi:se190107]>(std::__function::__policy_storage const*) @ 0x0000000016c0ad89 6. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000016c0abf5 7. /build/src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: DB::ExceptionKeepingTransform::work() @ 0x0000000016c0a6fe 8. /build/src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x00000000169bd00f 9. /build/src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x00000000169b2105 10. /build/src/Processors/Executors/PipelineExecutor.cpp:170: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x00000000169b16a7 11. /build/src/Processors/Executors/PushingPipelineExecutor.cpp:131: DB::PushingPipelineExecutor::finish() @ 0x00000000169c359f 12. /build/src/Server/TCPHandler.cpp:1128: DB::TCPHandler::processInsertQuery(DB::QueryState&) @ 0x00000000168f0d2c 13. /build/src/Server/TCPHandler.cpp:673: DB::TCPHandler::runImpl() @ 0x00000000168e68bc 14. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 15. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 16. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 17. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 18. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 19. ? @ 0x00007fbc6213eac3 20. ? @ 0x00007fbc621d0850 2025.07.28 11:51:25.517088 [ 7630 ] {} TCPHandler: Code: 469. DB::Exception: Constraint `c1` for table test_13.t0 (bdb51fc0-4143-4bd0-85e0-e7d2a63cbd6d) is violated at row 1. Expression: (c0 > 5). Column values: c0 = 3. (VIOLATED_CONSTRAINT), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.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&) @ 0x0000000013cd2239 4. /build/src/Processors/Transforms/CheckConstraintsTransform.cpp:119: DB::CheckConstraintsTransform::onConsume(DB::Chunk) @ 0x0000000016bfc0bc 5. /build/src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: void std::__function::__policy_invoker::__call_impl[abi:se190107]>(std::__function::__policy_storage const*) @ 0x0000000016c0ad89 6. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000016c0abf5 7. /build/src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: DB::ExceptionKeepingTransform::work() @ 0x0000000016c0a6fe 8. /build/src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x00000000169bd00f 9. /build/src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x00000000169b2105 10. /build/src/Processors/Executors/PipelineExecutor.cpp:170: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x00000000169b16a7 11. /build/src/Processors/Executors/PushingPipelineExecutor.cpp:131: DB::PushingPipelineExecutor::finish() @ 0x00000000169c359f 12. /build/src/Server/TCPHandler.cpp:1128: DB::TCPHandler::processInsertQuery(DB::QueryState&) @ 0x00000000168f0d2c 13. /build/src/Server/TCPHandler.cpp:673: DB::TCPHandler::runImpl() @ 0x00000000168e68bc 14. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 15. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 16. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 17. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 18. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 19. ? @ 0x00007fbc6213eac3 20. ? @ 0x00007fbc621d0850 2025.07.28 11:51:26.577949 [ 15481 ] {f71f819c-384a-4321-9c03-961b8a898feb} 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.6.10636.altinitytest (altinity build)) (from [::1]:47178) (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. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception>&>(int, FormatStringHelperImpl::type, std::type_identity>&>::type>, String&&, std::basic_string_view>&) @ 0x000000000de9098b 4. /build/src/DataTypes/getLeastSupertype.cpp:69: std::shared_ptr DB::(anonymous namespace)::throwOrReturn<(DB::LeastSupertypeOnError)0, std::vector, std::allocator>>>(std::vector, std::allocator>> const&, std::basic_string_view>, int) @ 0x0000000013c6a73e 5. /build/src/DataTypes/getLeastSupertype.cpp:547: std::shared_ptr DB::getLeastSupertype<(DB::LeastSupertypeOnError)0>(std::vector, std::allocator>> const&) @ 0x0000000013c6dd15 6. /build/src/Functions/if.cpp:1206: DB::(anonymous namespace)::FunctionIf::getReturnTypeImpl(std::vector, std::allocator>> const&) const @ 0x00000000140ba3ca 7. /build/src/Functions/IFunction.h:520: DB::IFunction::getReturnTypeImpl(std::vector> const&) const @ 0x000000000a06a2de 8. /build/src/Functions/IFunction.cpp:645: DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x0000000012d96b0c 9. /build/src/Functions/IFunction.cpp:577: DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x0000000012d9669c 10. /build/src/Functions/IFunction.cpp:606: DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x0000000012d96edc 11. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3544: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000014033cc9 12. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3838: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000014019a9e 13. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3980: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000014018e31 14. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:4304: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000014042fa7 15. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5605: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000014013749 16. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000140127f9 17. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000014011fce 18. /build/src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000001406ce8a 19. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000014973b42 20. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000001497268d 21. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000014974d24 22. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001492924b 23. /build/src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88641 24. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 25. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 26. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 27. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 28. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 29. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 30. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 31. ? @ 0x00007fbc6213eac3 2025.07.28 11:51:26.634387 [ 15481 ] {} 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. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception>&>(int, FormatStringHelperImpl::type, std::type_identity>&>::type>, String&&, std::basic_string_view>&) @ 0x000000000de9098b 4. /build/src/DataTypes/getLeastSupertype.cpp:69: std::shared_ptr DB::(anonymous namespace)::throwOrReturn<(DB::LeastSupertypeOnError)0, std::vector, std::allocator>>>(std::vector, std::allocator>> const&, std::basic_string_view>, int) @ 0x0000000013c6a73e 5. /build/src/DataTypes/getLeastSupertype.cpp:547: std::shared_ptr DB::getLeastSupertype<(DB::LeastSupertypeOnError)0>(std::vector, std::allocator>> const&) @ 0x0000000013c6dd15 6. /build/src/Functions/if.cpp:1206: DB::(anonymous namespace)::FunctionIf::getReturnTypeImpl(std::vector, std::allocator>> const&) const @ 0x00000000140ba3ca 7. /build/src/Functions/IFunction.h:520: DB::IFunction::getReturnTypeImpl(std::vector> const&) const @ 0x000000000a06a2de 8. /build/src/Functions/IFunction.cpp:645: DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x0000000012d96b0c 9. /build/src/Functions/IFunction.cpp:577: DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x0000000012d9669c 10. /build/src/Functions/IFunction.cpp:606: DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x0000000012d96edc 11. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3544: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000014033cc9 12. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3838: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000014019a9e 13. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3980: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000014018e31 14. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:4304: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000014042fa7 15. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5605: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000014013749 16. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000140127f9 17. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000014011fce 18. /build/src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000001406ce8a 19. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000014973b42 20. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000001497268d 21. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000014974d24 22. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001492924b 23. /build/src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88641 24. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 25. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 26. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 27. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 28. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 29. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 30. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 31. ? @ 0x00007fbc6213eac3 2025.07.28 11:51:28.221605 [ 3287 ] {4e803f3a-519c-4ab7-b248-4cbade43af5a} executeQuery: Code: 252. DB::Exception: Cannot move 10 parts at once, the limit is 5. Wait until some parts are merged and retry, move smaller partitions, or increase the setting 'max_parts_to_move'. (TOO_MANY_PARTS) (version 25.3.6.10636.altinitytest (altinity build)) (from [::1]:47248) (comment: 03248_max_parts_to_move.sql) (query 11, line 16) (in query: ALTER TABLE t MOVE PARTITION tuple() TO TABLE t2;), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, unsigned long&&, unsigned long const&) @ 0x00000000138d132b 4. /build/src/Storages/StorageMergeTree.cpp:2399: DB::StorageMergeTree::movePartitionToTable(std::shared_ptr const&, std::shared_ptr const&, std::shared_ptr) @ 0x000000001665a069 5. /build/src/Storages/MergeTree/MergeTreeData.cpp:5642: DB::MergeTreeData::movePartitionToTable(DB::PartitionCommand const&, std::shared_ptr) @ 0x0000000016356fde 6. /build/src/Storages/MergeTree/MergeTreeData.cpp:5721: DB::MergeTreeData::alterPartition(std::shared_ptr const&, std::vector> const&, std::shared_ptr) @ 0x000000001635814c 7. /build/src/Interpreters/InterpreterAlterQuery.cpp:242: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x00000000148def37 8. /build/src/Interpreters/InterpreterAlterQuery.cpp:77: DB::InterpreterAlterQuery::execute() @ 0x00000000148dcb0d 9. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88dc9 10. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 11. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 12. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 13. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 14. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 16. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 17. ? @ 0x00007fbc6213eac3 18. ? @ 0x00007fbc621d0850 2025.07.28 11:51:28.235764 [ 3287 ] {} TCPHandler: Code: 252. DB::Exception: Cannot move 10 parts at once, the limit is 5. Wait until some parts are merged and retry, move smaller partitions, or increase the setting 'max_parts_to_move'. (TOO_MANY_PARTS), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, unsigned long&&, unsigned long const&) @ 0x00000000138d132b 4. /build/src/Storages/StorageMergeTree.cpp:2399: DB::StorageMergeTree::movePartitionToTable(std::shared_ptr const&, std::shared_ptr const&, std::shared_ptr) @ 0x000000001665a069 5. /build/src/Storages/MergeTree/MergeTreeData.cpp:5642: DB::MergeTreeData::movePartitionToTable(DB::PartitionCommand const&, std::shared_ptr) @ 0x0000000016356fde 6. /build/src/Storages/MergeTree/MergeTreeData.cpp:5721: DB::MergeTreeData::alterPartition(std::shared_ptr const&, std::vector> const&, std::shared_ptr) @ 0x000000001635814c 7. /build/src/Interpreters/InterpreterAlterQuery.cpp:242: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x00000000148def37 8. /build/src/Interpreters/InterpreterAlterQuery.cpp:77: DB::InterpreterAlterQuery::execute() @ 0x00000000148dcb0d 9. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88dc9 10. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 11. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 12. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 13. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 14. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 16. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 17. ? @ 0x00007fbc6213eac3 18. ? @ 0x00007fbc621d0850 2025.07.28 11:51:28.465257 [ 11826 ] {d805703f-63f9-4ea5-b6c8-947832a3ead9} executeQuery: Code: 117. DB::Exception: Incorrect arguments h3Index: 72057594037927935, k: 10, error: 2: In scope SELECT h3HexRing(72057594037927935, toUInt16(10)). (INCORRECT_DATA) (version 25.3.6.10636.altinitytest (altinity build)) (from [::1]:47262) (comment: 01659_h3_buffer_overflow.sql) (query 9, line 13) (in query: SELECT h3HexRing(0xFFFFFFFFFFFFFF, toUInt16(10)) FORMAT Null;), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, unsigned long const&, int const&, unsigned int&) @ 0x000000000c227e8b 4. /build/src/Functions/h3HexRing.cpp:134: DB::(anonymous namespace)::FunctionH3HexRing::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000c2277d5 5. /build/src/Functions/IFunction.h:437: DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000a069f2a 6. /build/src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000012d9965a 7. /build/src/Functions/IFunction.cpp:351: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d93b02 8. /build/src/Functions/IFunction.cpp:177: DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d93698 9. /build/src/Functions/IFunction.cpp:343: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d93aad 10. /build/src/Functions/IFunction.cpp:420: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d95059 11. /build/src/Functions/IFunction.cpp:498: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d95c72 12. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3567: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000014034494 13. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3838: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000014019a9e 14. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3980: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000014018e31 15. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:4304: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000014042fa7 16. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5605: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000014013749 17. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000140127f9 18. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000014011fce 19. /build/src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000001406ce8a 20. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000014973b42 21. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000001497268d 22. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000014974d24 23. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001492924b 24. /build/src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88641 25. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 26. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 27. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 28. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 29. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 30. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 31. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 2025.07.28 11:51:28.476741 [ 11826 ] {} TCPHandler: Code: 117. DB::Exception: Incorrect arguments h3Index: 72057594037927935, k: 10, error: 2: In scope SELECT h3HexRing(72057594037927935, toUInt16(10)). (INCORRECT_DATA), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, unsigned long const&, int const&, unsigned int&) @ 0x000000000c227e8b 4. /build/src/Functions/h3HexRing.cpp:134: DB::(anonymous namespace)::FunctionH3HexRing::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000c2277d5 5. /build/src/Functions/IFunction.h:437: DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000a069f2a 6. /build/src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000012d9965a 7. /build/src/Functions/IFunction.cpp:351: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d93b02 8. /build/src/Functions/IFunction.cpp:177: DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d93698 9. /build/src/Functions/IFunction.cpp:343: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d93aad 10. /build/src/Functions/IFunction.cpp:420: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d95059 11. /build/src/Functions/IFunction.cpp:498: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d95c72 12. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3567: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000014034494 13. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3838: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000014019a9e 14. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3980: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000014018e31 15. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:4304: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000014042fa7 16. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5605: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000014013749 17. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000140127f9 18. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000014011fce 19. /build/src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000001406ce8a 20. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000014973b42 21. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000001497268d 22. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000014974d24 23. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001492924b 24. /build/src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88641 25. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 26. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 27. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 28. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 29. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 30. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 31. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 2025.07.28 11:51:28.606674 [ 11826 ] {f9eae0c7-8153-4061-bd27-12c3b2ae19b0} executeQuery: Code: 117. DB::Exception: Incorrect arguments h3Index: 72057594037927935, k: 10000, error: 2: In scope SELECT h3HexRing(72057594037927935, toUInt16(10000)). (INCORRECT_DATA) (version 25.3.6.10636.altinitytest (altinity build)) (from [::1]:47262) (comment: 01659_h3_buffer_overflow.sql) (query 10, line 14) (in query: SELECT h3HexRing(0xFFFFFFFFFFFFFF, toUInt16(10000)) FORMAT Null;), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, unsigned long const&, int const&, unsigned int&) @ 0x000000000c227e8b 4. /build/src/Functions/h3HexRing.cpp:134: DB::(anonymous namespace)::FunctionH3HexRing::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000c2277d5 5. /build/src/Functions/IFunction.h:437: DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000a069f2a 6. /build/src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000012d9965a 7. /build/src/Functions/IFunction.cpp:351: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d93b02 8. /build/src/Functions/IFunction.cpp:177: DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d93698 9. /build/src/Functions/IFunction.cpp:343: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d93aad 10. /build/src/Functions/IFunction.cpp:420: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d95059 11. /build/src/Functions/IFunction.cpp:498: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d95c72 12. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3567: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000014034494 13. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3838: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000014019a9e 14. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3980: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000014018e31 15. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:4304: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000014042fa7 16. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5605: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000014013749 17. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000140127f9 18. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000014011fce 19. /build/src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000001406ce8a 20. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000014973b42 21. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000001497268d 22. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000014974d24 23. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001492924b 24. /build/src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88641 25. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 26. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 27. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 28. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 29. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 30. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 31. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 2025.07.28 11:51:28.611927 [ 11826 ] {} TCPHandler: Code: 117. DB::Exception: Incorrect arguments h3Index: 72057594037927935, k: 10000, error: 2: In scope SELECT h3HexRing(72057594037927935, toUInt16(10000)). (INCORRECT_DATA), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, unsigned long const&, int const&, unsigned int&) @ 0x000000000c227e8b 4. /build/src/Functions/h3HexRing.cpp:134: DB::(anonymous namespace)::FunctionH3HexRing::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000c2277d5 5. /build/src/Functions/IFunction.h:437: DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000a069f2a 6. /build/src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000012d9965a 7. /build/src/Functions/IFunction.cpp:351: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d93b02 8. /build/src/Functions/IFunction.cpp:177: DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d93698 9. /build/src/Functions/IFunction.cpp:343: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d93aad 10. /build/src/Functions/IFunction.cpp:420: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d95059 11. /build/src/Functions/IFunction.cpp:498: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d95c72 12. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3567: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000014034494 13. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3838: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000014019a9e 14. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3980: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000014018e31 15. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:4304: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000014042fa7 16. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5605: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000014013749 17. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000140127f9 18. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000014011fce 19. /build/src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000001406ce8a 20. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000014973b42 21. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000001497268d 22. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000014974d24 23. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001492924b 24. /build/src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88641 25. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 26. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 27. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 28. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 29. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 30. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 31. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 2025.07.28 11:51:28.876727 [ 7630 ] {89175468-0fa0-4e0a-8ed9-e9325a634a89} executeQuery: Code: 44. DB::Exception: Cannot create table with column '_row_exists' for MergeTree engines because it is reserved for persistent virtual column. (ILLEGAL_COLUMN) (version 25.3.6.10636.altinitytest (altinity build)) (from [::1]:47330) (comment: 02454_disable_mergetree_with_lightweight_delete_column.sql) (query 2, line 3) (in query: CREATE TABLE t_row_exists (`a` int, `_row_exists` int) ENGINE = MergeTree ORDER BY a SETTINGS index_granularity = 3793, 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 = 0, compact_parts_max_bytes_to_buffer = 279908756, compact_parts_max_granules_to_buffer = 97, compact_parts_merge_max_bytes_to_prefetch_part = 6795754, merge_max_block_size = 6870, old_parts_lifetime = 209., prefer_fetch_merged_part_size_threshold = 10737418240, vertical_merge_algorithm_min_rows_to_activate = 1, vertical_merge_algorithm_min_columns_to_activate = 10, min_merge_bytes_to_use_direct_io = 6200436367, index_granularity_bytes = 21054155, use_const_adaptive_granularity = false, enable_index_granularity_compression = true, concurrent_part_removal_threshold = 12, 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 = 95017, primary_key_compress_block_size = 32998, 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. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x000000000a6a1e2b 4. /build/src/Interpreters/InterpreterCreateQuery.cpp:1048: DB::validateVirtualColumns(DB::IStorage const&) @ 0x00000000148f4059 5. /build/src/Interpreters/InterpreterCreateQuery.cpp:1962: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x0000000014900b3b 6. /build/src/Interpreters/InterpreterCreateQuery.cpp:1743: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000148f9aa9 7. /build/src/Interpreters/InterpreterCreateQuery.cpp:2352: DB::InterpreterCreateQuery::execute() @ 0x0000000014905a41 8. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88dc9 9. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 10. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 11. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 12. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 13. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 14. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 15. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 16. ? @ 0x00007fbc6213eac3 17. ? @ 0x00007fbc621d0850 2025.07.28 11:51:28.898998 [ 7630 ] {} TCPHandler: Code: 44. DB::Exception: Cannot create table with column '_row_exists' for MergeTree engines because it is reserved for persistent virtual column. (ILLEGAL_COLUMN), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x000000000a6a1e2b 4. /build/src/Interpreters/InterpreterCreateQuery.cpp:1048: DB::validateVirtualColumns(DB::IStorage const&) @ 0x00000000148f4059 5. /build/src/Interpreters/InterpreterCreateQuery.cpp:1962: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x0000000014900b3b 6. /build/src/Interpreters/InterpreterCreateQuery.cpp:1743: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000148f9aa9 7. /build/src/Interpreters/InterpreterCreateQuery.cpp:2352: DB::InterpreterCreateQuery::execute() @ 0x0000000014905a41 8. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88dc9 9. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 10. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 11. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 12. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 13. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 14. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 15. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 16. ? @ 0x00007fbc6213eac3 17. ? @ 0x00007fbc621d0850 2025.07.28 11:51:29.300662 [ 7630 ] {0e558b55-1bad-46fa-ba3f-7291bb72fc62} executeQuery: Code: 44. DB::Exception: Cannot add column `_row_exists`: this column name is reserved for persistent virtual column. (ILLEGAL_COLUMN) (version 25.3.6.10636.altinitytest (altinity build)) (from [::1]:47330) (comment: 02454_disable_mergetree_with_lightweight_delete_column.sql) (query 4, line 6) (in query: alter table t_row_exists add column _row_exists int;), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x000000000a06b56b 4. /build/src/Storages/AlterCommands.cpp:1456: DB::AlterCommands::validate(std::shared_ptr const&, std::shared_ptr) const @ 0x0000000015cf7cdc 5. /build/src/Interpreters/InterpreterAlterQuery.cpp:213: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x00000000148dea74 6. /build/src/Interpreters/InterpreterAlterQuery.cpp:77: DB::InterpreterAlterQuery::execute() @ 0x00000000148dcb0d 7. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88dc9 8. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 9. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 10. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 11. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 12. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 13. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 14. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 15. ? @ 0x00007fbc6213eac3 16. ? @ 0x00007fbc621d0850 2025.07.28 11:51:29.308057 [ 7630 ] {} TCPHandler: Code: 44. DB::Exception: Cannot add column `_row_exists`: this column name is reserved for persistent virtual column. (ILLEGAL_COLUMN), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x000000000a06b56b 4. /build/src/Storages/AlterCommands.cpp:1456: DB::AlterCommands::validate(std::shared_ptr const&, std::shared_ptr) const @ 0x0000000015cf7cdc 5. /build/src/Interpreters/InterpreterAlterQuery.cpp:213: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x00000000148dea74 6. /build/src/Interpreters/InterpreterAlterQuery.cpp:77: DB::InterpreterAlterQuery::execute() @ 0x00000000148dcb0d 7. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88dc9 8. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 9. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 10. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 11. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 12. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 13. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 14. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 15. ? @ 0x00007fbc6213eac3 16. ? @ 0x00007fbc621d0850 2025.07.28 11:51:29.374601 [ 7630 ] {e786d95a-40b0-4f71-a486-f0e8a57a39a0} executeQuery: Code: 44. DB::Exception: Cannot rename to `_row_exists`: this column name is reserved for persistent virtual column. (ILLEGAL_COLUMN) (version 25.3.6.10636.altinitytest (altinity build)) (from [::1]:47330) (comment: 02454_disable_mergetree_with_lightweight_delete_column.sql) (query 5, line 7) (in query: alter table t_row_exists rename column b to _row_exists;), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x000000000a06b56b 4. /build/src/Storages/AlterCommands.cpp:1679: DB::AlterCommands::validate(std::shared_ptr const&, std::shared_ptr) const @ 0x0000000015cf7613 5. /build/src/Interpreters/InterpreterAlterQuery.cpp:213: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x00000000148dea74 6. /build/src/Interpreters/InterpreterAlterQuery.cpp:77: DB::InterpreterAlterQuery::execute() @ 0x00000000148dcb0d 7. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88dc9 8. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 9. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 10. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 11. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 12. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 13. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 14. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 15. ? @ 0x00007fbc6213eac3 16. ? @ 0x00007fbc621d0850 2025.07.28 11:51:29.394588 [ 7630 ] {} TCPHandler: Code: 44. DB::Exception: Cannot rename to `_row_exists`: this column name is reserved for persistent virtual column. (ILLEGAL_COLUMN), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x000000000a06b56b 4. /build/src/Storages/AlterCommands.cpp:1679: DB::AlterCommands::validate(std::shared_ptr const&, std::shared_ptr) const @ 0x0000000015cf7613 5. /build/src/Interpreters/InterpreterAlterQuery.cpp:213: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x00000000148dea74 6. /build/src/Interpreters/InterpreterAlterQuery.cpp:77: DB::InterpreterAlterQuery::execute() @ 0x00000000148dcb0d 7. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88dc9 8. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 9. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 10. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 11. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 12. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 13. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 14. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 15. ? @ 0x00007fbc6213eac3 16. ? @ 0x00007fbc621d0850 2025.07.28 11:51:29.490827 [ 7630 ] {4ba0a7a3-a60e-4b29-bb5f-4ccf8c0b2d49} executeQuery: Code: 10. DB::Exception: Wrong column name. Cannot find column `_row_exists` to rename. (NOT_FOUND_COLUMN_IN_BLOCK) (version 25.3.6.10636.altinitytest (altinity build)) (from [::1]:47330) (comment: 02454_disable_mergetree_with_lightweight_delete_column.sql) (query 6, line 8) (in query: alter table t_row_exists rename column _row_exists to c;), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Storages/AlterCommands.cpp:1669: DB::AlterCommands::validate(std::shared_ptr const&, std::shared_ptr) const @ 0x0000000015cf6f3c 4. /build/src/Interpreters/InterpreterAlterQuery.cpp:213: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x00000000148dea74 5. /build/src/Interpreters/InterpreterAlterQuery.cpp:77: DB::InterpreterAlterQuery::execute() @ 0x00000000148dcb0d 6. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88dc9 7. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 8. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 9. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 10. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 11. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 12. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 13. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 14. ? @ 0x00007fbc6213eac3 15. ? @ 0x00007fbc621d0850 2025.07.28 11:51:29.512181 [ 7630 ] {} TCPHandler: Code: 10. DB::Exception: Wrong column name. Cannot find column `_row_exists` to rename. (NOT_FOUND_COLUMN_IN_BLOCK), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Storages/AlterCommands.cpp:1669: DB::AlterCommands::validate(std::shared_ptr const&, std::shared_ptr) const @ 0x0000000015cf6f3c 4. /build/src/Interpreters/InterpreterAlterQuery.cpp:213: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x00000000148dea74 5. /build/src/Interpreters/InterpreterAlterQuery.cpp:77: DB::InterpreterAlterQuery::execute() @ 0x00000000148dcb0d 6. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88dc9 7. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 8. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 9. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 10. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 11. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 12. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 13. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 14. ? @ 0x00007fbc6213eac3 15. ? @ 0x00007fbc621d0850 2025.07.28 11:51:29.639849 [ 7630 ] {535cd61f-9b5f-4e46-a9e8-e0ba57448d11} executeQuery: Code: 10. DB::Exception: Wrong column name. Cannot find column `_row_exists` to drop. (NOT_FOUND_COLUMN_IN_BLOCK) (version 25.3.6.10636.altinitytest (altinity build)) (from [::1]:47330) (comment: 02454_disable_mergetree_with_lightweight_delete_column.sql) (query 7, line 9) (in query: alter table t_row_exists drop column _row_exists;), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Storages/AlterCommands.cpp:1618: DB::AlterCommands::validate(std::shared_ptr const&, std::shared_ptr) const @ 0x0000000015cf79cf 4. /build/src/Interpreters/InterpreterAlterQuery.cpp:213: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x00000000148dea74 5. /build/src/Interpreters/InterpreterAlterQuery.cpp:77: DB::InterpreterAlterQuery::execute() @ 0x00000000148dcb0d 6. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88dc9 7. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 8. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 9. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 10. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 11. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 12. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 13. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 14. ? @ 0x00007fbc6213eac3 15. ? @ 0x00007fbc621d0850 2025.07.28 11:51:29.652350 [ 7630 ] {} TCPHandler: Code: 10. DB::Exception: Wrong column name. Cannot find column `_row_exists` to drop. (NOT_FOUND_COLUMN_IN_BLOCK), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Storages/AlterCommands.cpp:1618: DB::AlterCommands::validate(std::shared_ptr const&, std::shared_ptr) const @ 0x0000000015cf79cf 4. /build/src/Interpreters/InterpreterAlterQuery.cpp:213: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x00000000148dea74 5. /build/src/Interpreters/InterpreterAlterQuery.cpp:77: DB::InterpreterAlterQuery::execute() @ 0x00000000148dcb0d 6. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88dc9 7. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 8. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 9. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 10. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 11. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 12. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 13. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 14. ? @ 0x00007fbc6213eac3 15. ? @ 0x00007fbc621d0850 2025.07.28 11:51:29.725050 [ 7630 ] {08cd65fe-19a4-40b0-a876-b791fb2d3d01} executeQuery: Code: 10. DB::Exception: Wrong column name. Cannot find column `unknown_column` to drop. (NOT_FOUND_COLUMN_IN_BLOCK) (version 25.3.6.10636.altinitytest (altinity build)) (from [::1]:47330) (comment: 02454_disable_mergetree_with_lightweight_delete_column.sql) (query 8, line 10) (in query: alter table t_row_exists drop column unknown_column;), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Storages/AlterCommands.cpp:1618: DB::AlterCommands::validate(std::shared_ptr const&, std::shared_ptr) const @ 0x0000000015cf79cf 4. /build/src/Interpreters/InterpreterAlterQuery.cpp:213: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x00000000148dea74 5. /build/src/Interpreters/InterpreterAlterQuery.cpp:77: DB::InterpreterAlterQuery::execute() @ 0x00000000148dcb0d 6. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88dc9 7. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 8. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 9. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 10. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 11. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 12. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 13. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 14. ? @ 0x00007fbc6213eac3 15. ? @ 0x00007fbc621d0850 2025.07.28 11:51:29.729395 [ 7630 ] {} TCPHandler: Code: 10. DB::Exception: Wrong column name. Cannot find column `unknown_column` to drop. (NOT_FOUND_COLUMN_IN_BLOCK), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Storages/AlterCommands.cpp:1618: DB::AlterCommands::validate(std::shared_ptr const&, std::shared_ptr) const @ 0x0000000015cf79cf 4. /build/src/Interpreters/InterpreterAlterQuery.cpp:213: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x00000000148dea74 5. /build/src/Interpreters/InterpreterAlterQuery.cpp:77: DB::InterpreterAlterQuery::execute() @ 0x00000000148dcb0d 6. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88dc9 7. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 8. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 9. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 10. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 11. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 12. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 13. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 14. ? @ 0x00007fbc6213eac3 15. ? @ 0x00007fbc621d0850 2025.07.28 11:51:30.348460 [ 3287 ] {8acb5bea-a40a-43a8-9797-6054d443640e} executeQuery: Code: 291. DB::Exception: Path 'data_*_{_partition_id}.csv' contains globs, so the table is in readonly mode. (DATABASE_ACCESS_DENIED) (version 25.3.6.10636.altinitytest (altinity build)) (from [::1]:47342) (comment: 03037_s3_write_to_globbed_partitioned_path.sql) (query 1, line 3) (in query: insert into function s3('http://localhost:11111/test/data_*_{_partition_id}.csv') partition by number % 3 select * from numbers(10);), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x000000000a06b56b 4. /build/src/Storages/ObjectStorage/StorageObjectStorage.cpp:406: DB::StorageObjectStorage::write(std::shared_ptr const&, std::shared_ptr const&, std::shared_ptr, bool) @ 0x00000000132c2e09 5. /build/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&) @ 0x0000000016cb4984 6. /build/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*) @ 0x000000001492df0b 7. /build/src/Interpreters/InterpreterInsertQuery.cpp:503: DB::InterpreterInsertQuery::buildPreAndSinkChains(unsigned long, unsigned long, std::shared_ptr, unsigned long, std::shared_ptr const&, DB::Block const&) @ 0x000000001492f8f2 8. /build/src/Interpreters/InterpreterInsertQuery.cpp:701: DB::InterpreterInsertQuery::buildInsertSelectPipeline(DB::ASTInsertQuery&, std::shared_ptr) @ 0x00000000149310ac 9. /build/src/Interpreters/InterpreterInsertQuery.cpp:870: DB::InterpreterInsertQuery::execute() @ 0x0000000014933e3d 10. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88dc9 11. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 12. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 13. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 14. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 15. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 16. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 17. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 18. ? @ 0x00007fbc6213eac3 19. ? @ 0x00007fbc621d0850 2025.07.28 11:51:30.351847 [ 3287 ] {} TCPHandler: Code: 291. DB::Exception: Path 'data_*_{_partition_id}.csv' contains globs, so the table is in readonly mode. (DATABASE_ACCESS_DENIED), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x000000000a06b56b 4. /build/src/Storages/ObjectStorage/StorageObjectStorage.cpp:406: DB::StorageObjectStorage::write(std::shared_ptr const&, std::shared_ptr const&, std::shared_ptr, bool) @ 0x00000000132c2e09 5. /build/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&) @ 0x0000000016cb4984 6. /build/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*) @ 0x000000001492df0b 7. /build/src/Interpreters/InterpreterInsertQuery.cpp:503: DB::InterpreterInsertQuery::buildPreAndSinkChains(unsigned long, unsigned long, std::shared_ptr, unsigned long, std::shared_ptr const&, DB::Block const&) @ 0x000000001492f8f2 8. /build/src/Interpreters/InterpreterInsertQuery.cpp:701: DB::InterpreterInsertQuery::buildInsertSelectPipeline(DB::ASTInsertQuery&, std::shared_ptr) @ 0x00000000149310ac 9. /build/src/Interpreters/InterpreterInsertQuery.cpp:870: DB::InterpreterInsertQuery::execute() @ 0x0000000014933e3d 10. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88dc9 11. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 12. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 13. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 14. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 15. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 16. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 17. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 18. ? @ 0x00007fbc6213eac3 19. ? @ 0x00007fbc621d0850 2025.07.28 11:51:30.469975 [ 4581 ] {} 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. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x000000000c25bc4b 4. /build/src/Access/SettingsConstraints.cpp:343: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000138596e3 5. /build/src/Access/SettingsConstraints.cpp:300: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000013858faf 6. /build/src/Access/SettingsConstraints.cpp:209: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x00000000138592b8 7. /build/src/Interpreters/Context.cpp:2690: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000014436134 8. /build/src/Interpreters/Context.cpp:2729: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x000000001443662b 9. /build/src/Server/TCPHandler.cpp:2158: DB::TCPHandler::processQuery(std::optional&) @ 0x00000000168f61df 10. /build/src/Server/TCPHandler.cpp:918: DB::TCPHandler::receivePacketsExpectQuery(std::optional&) @ 0x00000000168ef965 11. /build/src/Server/TCPHandler.cpp:491: DB::TCPHandler::runImpl() @ 0x00000000168e5eb4 12. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 13. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 14. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 16. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 17. ? @ 0x00007fbc6213eac3 18. ? @ 0x00007fbc621d0850 2025.07.28 11:51:30.471954 [ 4581 ] {} 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. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000000a074fcb 4. /build/src/Server/TCPHandler.cpp:897: DB::TCPHandler::receivePacketsExpectQuery(std::optional&) @ 0x00000000168efa89 5. /build/src/Server/TCPHandler.cpp:491: DB::TCPHandler::runImpl() @ 0x00000000168e5eb4 6. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 7. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 8. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 9. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 10. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 11. ? @ 0x00007fbc6213eac3 12. ? @ 0x00007fbc621d0850 2025.07.28 11:51:31.445745 [ 15481 ] {} 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. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception>&, String>(int, FormatStringHelperImpl>&>::type, std::type_identity::type>, std::basic_string_view>&, String&&) @ 0x000000001385a5eb 4. /build/src/Access/SettingsConstraints.cpp:376: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000013859b18 5. /build/src/Access/SettingsConstraints.cpp:300: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000013858faf 6. /build/src/Access/SettingsConstraints.cpp:209: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000013859223 7. /build/src/Interpreters/Context.cpp:2690: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000014436134 8. /build/src/Interpreters/Context.cpp:2729: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x000000001443662b 9. /build/src/Server/HTTPHandler.cpp:457: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000001686d165 10. /build/src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x0000000016870807 11. /build/src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x0000000016907e99 12. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 13. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 14. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 15. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 16. ? @ 0x00007fbc6213eac3 17. ? @ 0x00007fbc621d0850 (version 25.3.6.10636.altinitytest (altinity build)) 2025.07.28 11:51:31.610923 [ 3287 ] {3197a9c1-1dac-4c1f-9437-9533b31cc5c6} executeQuery: Code: 127. DB::Exception: Duplicated index name idx_a is not allowed. Please use a different index name. (ILLEGAL_INDEX) (version 25.3.6.10636.altinitytest (altinity build)) (from [::1]:32994) (comment: 02884_duplicate_index_name.sql) (query 2, line 3) (in query: CREATE TABLE test_dup_index (`a` Int64, `b` Int64, INDEX idx_a a TYPE minmax GRANULARITY 1, INDEX idx_a b TYPE minmax GRANULARITY 1) ENGINE = MergeTree ORDER BY a SETTINGS index_granularity = 24104, min_bytes_for_wide_part = 551203687, 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 = 487701569, compact_parts_max_granules_to_buffer = 150, compact_parts_merge_max_bytes_to_prefetch_part = 8611826, merge_max_block_size = 4616, old_parts_lifetime = 395., prefer_fetch_merged_part_size_threshold = 1, 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 = 1787828, use_const_adaptive_granularity = false, enable_index_granularity_compression = false, concurrent_part_removal_threshold = 70, 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 = 65279, primary_key_compress_block_size = 45890, 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. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x000000000a06b56b 4. /build/src/Interpreters/InterpreterCreateQuery.cpp:792: DB::InterpreterCreateQuery::getTablePropertiesAndNormalizeCreateQuery(DB::ASTCreateQuery&, DB::LoadingStrictnessLevel) const @ 0x00000000148f14ba 5. /build/src/Interpreters/InterpreterCreateQuery.cpp:1657: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000148f901b 6. /build/src/Interpreters/InterpreterCreateQuery.cpp:2352: DB::InterpreterCreateQuery::execute() @ 0x0000000014905a41 7. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88dc9 8. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 9. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 10. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 11. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 12. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 13. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 14. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 15. ? @ 0x00007fbc6213eac3 16. ? @ 0x00007fbc621d0850 2025.07.28 11:51:31.622254 [ 3287 ] {} TCPHandler: Code: 127. DB::Exception: Duplicated index name idx_a is not allowed. Please use a different index name. (ILLEGAL_INDEX), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x000000000a06b56b 4. /build/src/Interpreters/InterpreterCreateQuery.cpp:792: DB::InterpreterCreateQuery::getTablePropertiesAndNormalizeCreateQuery(DB::ASTCreateQuery&, DB::LoadingStrictnessLevel) const @ 0x00000000148f14ba 5. /build/src/Interpreters/InterpreterCreateQuery.cpp:1657: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000148f901b 6. /build/src/Interpreters/InterpreterCreateQuery.cpp:2352: DB::InterpreterCreateQuery::execute() @ 0x0000000014905a41 7. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88dc9 8. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 9. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 10. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 11. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 12. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 13. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 14. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 15. ? @ 0x00007fbc6213eac3 16. ? @ 0x00007fbc621d0850 2025.07.28 11:51:31.910648 [ 4581 ] {121745f8-86c4-4f82-bb81-2307f265af7e} 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('[42]', 'Array(LowCardinality(UInt64))'). (SUSPICIOUS_TYPE_FOR_LOW_CARDINALITY) (version 25.3.6.10636.altinitytest (altinity build)) (from [::1]:33012) (comment: 02981_nested_bad_types.sql) (query 4, line 6) (in query: select [42]::Array(LowCardinality(UInt64));), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x000000000a06b56b 4. /build/src/Interpreters/parseColumnsListForTableFunction.cpp:67: DB::validateDataType(std::shared_ptr const&, DB::DataTypeValidationSettings const&)::$_0::operator()(DB::IDataType const&) const @ 0x0000000014ccea0b 5. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000013bd9034 6. /build/src/Interpreters/parseColumnsListForTableFunction.cpp:173: DB::validateDataType(std::shared_ptr const&, DB::DataTypeValidationSettings const&) @ 0x0000000014ccde2d 7. /build/src/Functions/CastOverloadResolver.cpp:128: DB::CastOverloadResolverImpl::getReturnTypeImpl(std::vector> const&) const @ 0x0000000012dcd4a5 8. /build/src/Functions/IFunction.cpp:645: DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x0000000012d96b0c 9. /build/src/Functions/IFunction.cpp:585: DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x0000000012d9665b 10. /build/src/Functions/IFunction.cpp:606: DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x0000000012d96edc 11. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3544: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000014033cc9 12. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3838: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000014019a9e 13. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3980: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000014018e31 14. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:4304: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000014042fa7 15. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5605: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000014013749 16. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000140127f9 17. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000014011fce 18. /build/src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000001406ce8a 19. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000014973b42 20. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000001497268d 21. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000014974d24 22. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001492924b 23. /build/src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88641 24. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 25. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 26. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 27. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 28. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 29. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 30. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 31. ? @ 0x00007fbc6213eac3 2025.07.28 11:51:31.915022 [ 4581 ] {} 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('[42]', 'Array(LowCardinality(UInt64))'). (SUSPICIOUS_TYPE_FOR_LOW_CARDINALITY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x000000000a06b56b 4. /build/src/Interpreters/parseColumnsListForTableFunction.cpp:67: DB::validateDataType(std::shared_ptr const&, DB::DataTypeValidationSettings const&)::$_0::operator()(DB::IDataType const&) const @ 0x0000000014ccea0b 5. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000013bd9034 6. /build/src/Interpreters/parseColumnsListForTableFunction.cpp:173: DB::validateDataType(std::shared_ptr const&, DB::DataTypeValidationSettings const&) @ 0x0000000014ccde2d 7. /build/src/Functions/CastOverloadResolver.cpp:128: DB::CastOverloadResolverImpl::getReturnTypeImpl(std::vector> const&) const @ 0x0000000012dcd4a5 8. /build/src/Functions/IFunction.cpp:645: DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x0000000012d96b0c 9. /build/src/Functions/IFunction.cpp:585: DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x0000000012d9665b 10. /build/src/Functions/IFunction.cpp:606: DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x0000000012d96edc 11. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3544: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000014033cc9 12. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3838: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000014019a9e 13. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3980: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000014018e31 14. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:4304: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000014042fa7 15. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5605: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000014013749 16. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000140127f9 17. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000014011fce 18. /build/src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000001406ce8a 19. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000014973b42 20. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000001497268d 21. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000014974d24 22. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001492924b 23. /build/src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88641 24. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 25. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 26. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 27. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 28. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 29. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 30. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 31. ? @ 0x00007fbc6213eac3 2025.07.28 11:51:31.943253 [ 4581 ] {9baf6651-87a9-4501-a79d-d13d0d66466f} 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('[[[42]]]', 'Array(Array(Array(LowCardinality(UInt64))))'). (SUSPICIOUS_TYPE_FOR_LOW_CARDINALITY) (version 25.3.6.10636.altinitytest (altinity build)) (from [::1]:33012) (comment: 02981_nested_bad_types.sql) (query 5, line 7) (in query: select [[[42]]]::Array(Array(Array(LowCardinality(UInt64))));), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x000000000a06b56b 4. /build/src/Interpreters/parseColumnsListForTableFunction.cpp:67: DB::validateDataType(std::shared_ptr const&, DB::DataTypeValidationSettings const&)::$_0::operator()(DB::IDataType const&) const @ 0x0000000014ccea0b 5. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000013bd9034 6. /build/src/Interpreters/parseColumnsListForTableFunction.cpp:173: DB::validateDataType(std::shared_ptr const&, DB::DataTypeValidationSettings const&) @ 0x0000000014ccde2d 7. /build/src/Functions/CastOverloadResolver.cpp:128: DB::CastOverloadResolverImpl::getReturnTypeImpl(std::vector> const&) const @ 0x0000000012dcd4a5 8. /build/src/Functions/IFunction.cpp:645: DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x0000000012d96b0c 9. /build/src/Functions/IFunction.cpp:585: DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x0000000012d9665b 10. /build/src/Functions/IFunction.cpp:606: DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x0000000012d96edc 11. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3544: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000014033cc9 12. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3838: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000014019a9e 13. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3980: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000014018e31 14. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:4304: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000014042fa7 15. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5605: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000014013749 16. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000140127f9 17. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000014011fce 18. /build/src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000001406ce8a 19. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000014973b42 20. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000001497268d 21. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000014974d24 22. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001492924b 23. /build/src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88641 24. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 25. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 26. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 27. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 28. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 29. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 30. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 31. ? @ 0x00007fbc6213eac3 2025.07.28 11:51:31.947908 [ 4581 ] {} 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('[[[42]]]', 'Array(Array(Array(LowCardinality(UInt64))))'). (SUSPICIOUS_TYPE_FOR_LOW_CARDINALITY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x000000000a06b56b 4. /build/src/Interpreters/parseColumnsListForTableFunction.cpp:67: DB::validateDataType(std::shared_ptr const&, DB::DataTypeValidationSettings const&)::$_0::operator()(DB::IDataType const&) const @ 0x0000000014ccea0b 5. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000013bd9034 6. /build/src/Interpreters/parseColumnsListForTableFunction.cpp:173: DB::validateDataType(std::shared_ptr const&, DB::DataTypeValidationSettings const&) @ 0x0000000014ccde2d 7. /build/src/Functions/CastOverloadResolver.cpp:128: DB::CastOverloadResolverImpl::getReturnTypeImpl(std::vector> const&) const @ 0x0000000012dcd4a5 8. /build/src/Functions/IFunction.cpp:645: DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x0000000012d96b0c 9. /build/src/Functions/IFunction.cpp:585: DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x0000000012d9665b 10. /build/src/Functions/IFunction.cpp:606: DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x0000000012d96edc 11. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3544: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000014033cc9 12. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3838: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000014019a9e 13. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3980: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000014018e31 14. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:4304: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000014042fa7 15. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5605: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000014013749 16. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000140127f9 17. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000014011fce 18. /build/src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000001406ce8a 19. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000014973b42 20. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000001497268d 21. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000014974d24 22. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001492924b 23. /build/src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88641 24. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 25. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 26. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 27. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 28. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 29. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 30. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 31. ? @ 0x00007fbc6213eac3 2025.07.28 11:51:32.059833 [ 4581 ] {ae7944b2-7018-4163-b455-bdb741069fa0} 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(map('a', 42), 'Map(String, LowCardinality(UInt64))'). (SUSPICIOUS_TYPE_FOR_LOW_CARDINALITY) (version 25.3.6.10636.altinitytest (altinity build)) (from [::1]:33012) (comment: 02981_nested_bad_types.sql) (query 6, line 8) (in query: select map('a', 42)::Map(String, LowCardinality(UInt64));), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x000000000a06b56b 4. /build/src/Interpreters/parseColumnsListForTableFunction.cpp:67: DB::validateDataType(std::shared_ptr const&, DB::DataTypeValidationSettings const&)::$_0::operator()(DB::IDataType const&) const @ 0x0000000014ccea0b 5. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000013bf3d4b 6. /build/src/Interpreters/parseColumnsListForTableFunction.cpp:173: DB::validateDataType(std::shared_ptr const&, DB::DataTypeValidationSettings const&) @ 0x0000000014ccde2d 7. /build/src/Functions/CastOverloadResolver.cpp:128: DB::CastOverloadResolverImpl::getReturnTypeImpl(std::vector> const&) const @ 0x0000000012dcd4a5 8. /build/src/Functions/IFunction.cpp:645: DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x0000000012d96b0c 9. /build/src/Functions/IFunction.cpp:585: DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x0000000012d9665b 10. /build/src/Functions/IFunction.cpp:606: DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x0000000012d96edc 11. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3544: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000014033cc9 12. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3838: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000014019a9e 13. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3980: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000014018e31 14. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:4304: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000014042fa7 15. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5605: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000014013749 16. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000140127f9 17. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000014011fce 18. /build/src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000001406ce8a 19. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000014973b42 20. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000001497268d 21. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000014974d24 22. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001492924b 23. /build/src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88641 24. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 25. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 26. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 27. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 28. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 29. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 30. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 31. ? @ 0x00007fbc6213eac3 2025.07.28 11:51:32.069017 [ 4581 ] {} 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(map('a', 42), 'Map(String, LowCardinality(UInt64))'). (SUSPICIOUS_TYPE_FOR_LOW_CARDINALITY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x000000000a06b56b 4. /build/src/Interpreters/parseColumnsListForTableFunction.cpp:67: DB::validateDataType(std::shared_ptr const&, DB::DataTypeValidationSettings const&)::$_0::operator()(DB::IDataType const&) const @ 0x0000000014ccea0b 5. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000013bf3d4b 6. /build/src/Interpreters/parseColumnsListForTableFunction.cpp:173: DB::validateDataType(std::shared_ptr const&, DB::DataTypeValidationSettings const&) @ 0x0000000014ccde2d 7. /build/src/Functions/CastOverloadResolver.cpp:128: DB::CastOverloadResolverImpl::getReturnTypeImpl(std::vector> const&) const @ 0x0000000012dcd4a5 8. /build/src/Functions/IFunction.cpp:645: DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x0000000012d96b0c 9. /build/src/Functions/IFunction.cpp:585: DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x0000000012d9665b 10. /build/src/Functions/IFunction.cpp:606: DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x0000000012d96edc 11. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3544: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000014033cc9 12. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3838: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000014019a9e 13. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3980: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000014018e31 14. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:4304: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000014042fa7 15. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5605: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000014013749 16. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000140127f9 17. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000014011fce 18. /build/src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000001406ce8a 19. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000014973b42 20. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000001497268d 21. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000014974d24 22. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001492924b 23. /build/src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88641 24. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 25. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 26. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 27. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 28. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 29. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 30. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 31. ? @ 0x00007fbc6213eac3 2025.07.28 11:51:32.127998 [ 4581 ] {32565819-c1fe-4cad-af3e-04f610c0f392} 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(map('a', map('b', [42])), 'Map(String, Map(String, Array(LowCardinality(UInt64))))'). (SUSPICIOUS_TYPE_FOR_LOW_CARDINALITY) (version 25.3.6.10636.altinitytest (altinity build)) (from [::1]:33012) (comment: 02981_nested_bad_types.sql) (query 7, line 9) (in query: select map('a', map('b', [42]))::Map(String, Map(String, Array(LowCardinality(UInt64))));), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x000000000a06b56b 4. /build/src/Interpreters/parseColumnsListForTableFunction.cpp:67: DB::validateDataType(std::shared_ptr const&, DB::DataTypeValidationSettings const&)::$_0::operator()(DB::IDataType const&) const @ 0x0000000014ccea0b 5. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000013bd9034 6. /build/src/Interpreters/parseColumnsListForTableFunction.cpp:173: DB::validateDataType(std::shared_ptr const&, DB::DataTypeValidationSettings const&) @ 0x0000000014ccde2d 7. /build/src/Functions/CastOverloadResolver.cpp:128: DB::CastOverloadResolverImpl::getReturnTypeImpl(std::vector> const&) const @ 0x0000000012dcd4a5 8. /build/src/Functions/IFunction.cpp:645: DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x0000000012d96b0c 9. /build/src/Functions/IFunction.cpp:585: DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x0000000012d9665b 10. /build/src/Functions/IFunction.cpp:606: DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x0000000012d96edc 11. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3544: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000014033cc9 12. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3838: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000014019a9e 13. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3980: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000014018e31 14. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:4304: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000014042fa7 15. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5605: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000014013749 16. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000140127f9 17. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000014011fce 18. /build/src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000001406ce8a 19. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000014973b42 20. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000001497268d 21. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000014974d24 22. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001492924b 23. /build/src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88641 24. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 25. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 26. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 27. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 28. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 29. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 30. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 31. ? @ 0x00007fbc6213eac3 2025.07.28 11:51:32.134058 [ 4581 ] {} 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(map('a', map('b', [42])), 'Map(String, Map(String, Array(LowCardinality(UInt64))))'). (SUSPICIOUS_TYPE_FOR_LOW_CARDINALITY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x000000000a06b56b 4. /build/src/Interpreters/parseColumnsListForTableFunction.cpp:67: DB::validateDataType(std::shared_ptr const&, DB::DataTypeValidationSettings const&)::$_0::operator()(DB::IDataType const&) const @ 0x0000000014ccea0b 5. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000013bd9034 6. /build/src/Interpreters/parseColumnsListForTableFunction.cpp:173: DB::validateDataType(std::shared_ptr const&, DB::DataTypeValidationSettings const&) @ 0x0000000014ccde2d 7. /build/src/Functions/CastOverloadResolver.cpp:128: DB::CastOverloadResolverImpl::getReturnTypeImpl(std::vector> const&) const @ 0x0000000012dcd4a5 8. /build/src/Functions/IFunction.cpp:645: DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x0000000012d96b0c 9. /build/src/Functions/IFunction.cpp:585: DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x0000000012d9665b 10. /build/src/Functions/IFunction.cpp:606: DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x0000000012d96edc 11. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3544: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000014033cc9 12. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3838: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000014019a9e 13. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3980: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000014018e31 14. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:4304: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000014042fa7 15. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5605: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000014013749 16. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000140127f9 17. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000014011fce 18. /build/src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000001406ce8a 19. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000014973b42 20. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000001497268d 21. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000014974d24 22. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001492924b 23. /build/src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88641 24. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 25. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 26. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 27. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 28. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 29. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 30. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 31. ? @ 0x00007fbc6213eac3 2025.07.28 11:51:32.257151 [ 4581 ] {8e5da552-a93a-4d9d-bc9e-4ba0f97372ab} 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(('a', 42), 'Tuple(String, LowCardinality(UInt64))'). (SUSPICIOUS_TYPE_FOR_LOW_CARDINALITY) (version 25.3.6.10636.altinitytest (altinity build)) (from [::1]:33012) (comment: 02981_nested_bad_types.sql) (query 8, line 10) (in query: select tuple('a', 42)::Tuple(String, LowCardinality(UInt64));), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x000000000a06b56b 4. /build/src/Interpreters/parseColumnsListForTableFunction.cpp:67: DB::validateDataType(std::shared_ptr const&, DB::DataTypeValidationSettings const&)::$_0::operator()(DB::IDataType const&) const @ 0x0000000014ccea0b 5. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000013c0b669 6. /build/src/Interpreters/parseColumnsListForTableFunction.cpp:173: DB::validateDataType(std::shared_ptr const&, DB::DataTypeValidationSettings const&) @ 0x0000000014ccde2d 7. /build/src/Functions/CastOverloadResolver.cpp:128: DB::CastOverloadResolverImpl::getReturnTypeImpl(std::vector> const&) const @ 0x0000000012dcd4a5 8. /build/src/Functions/IFunction.cpp:645: DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x0000000012d96b0c 9. /build/src/Functions/IFunction.cpp:585: DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x0000000012d9665b 10. /build/src/Functions/IFunction.cpp:606: DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x0000000012d96edc 11. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3544: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000014033cc9 12. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3838: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000014019a9e 13. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3980: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000014018e31 14. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:4304: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000014042fa7 15. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5605: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000014013749 16. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000140127f9 17. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000014011fce 18. /build/src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000001406ce8a 19. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000014973b42 20. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000001497268d 21. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000014974d24 22. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001492924b 23. /build/src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88641 24. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 25. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 26. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 27. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 28. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 29. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 30. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 31. ? @ 0x00007fbc6213eac3 2025.07.28 11:51:32.261764 [ 4581 ] {} 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(('a', 42), 'Tuple(String, LowCardinality(UInt64))'). (SUSPICIOUS_TYPE_FOR_LOW_CARDINALITY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x000000000a06b56b 4. /build/src/Interpreters/parseColumnsListForTableFunction.cpp:67: DB::validateDataType(std::shared_ptr const&, DB::DataTypeValidationSettings const&)::$_0::operator()(DB::IDataType const&) const @ 0x0000000014ccea0b 5. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000013c0b669 6. /build/src/Interpreters/parseColumnsListForTableFunction.cpp:173: DB::validateDataType(std::shared_ptr const&, DB::DataTypeValidationSettings const&) @ 0x0000000014ccde2d 7. /build/src/Functions/CastOverloadResolver.cpp:128: DB::CastOverloadResolverImpl::getReturnTypeImpl(std::vector> const&) const @ 0x0000000012dcd4a5 8. /build/src/Functions/IFunction.cpp:645: DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x0000000012d96b0c 9. /build/src/Functions/IFunction.cpp:585: DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x0000000012d9665b 10. /build/src/Functions/IFunction.cpp:606: DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x0000000012d96edc 11. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3544: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000014033cc9 12. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3838: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000014019a9e 13. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3980: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000014018e31 14. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:4304: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000014042fa7 15. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5605: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000014013749 16. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000140127f9 17. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000014011fce 18. /build/src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000001406ce8a 19. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000014973b42 20. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000001497268d 21. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000014974d24 22. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001492924b 23. /build/src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88641 24. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 25. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 26. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 27. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 28. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 29. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 30. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 31. ? @ 0x00007fbc6213eac3 2025.07.28 11:51:32.363065 [ 4581 ] {b9a2babe-93ee-4454-ba51-0499f5d84e13} 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(('a', [map('b', 42)]), 'Tuple(String, Array(Map(String, LowCardinality(UInt64))))'). (SUSPICIOUS_TYPE_FOR_LOW_CARDINALITY) (version 25.3.6.10636.altinitytest (altinity build)) (from [::1]:33012) (comment: 02981_nested_bad_types.sql) (query 9, line 11) (in query: select tuple('a', [map('b', 42)])::Tuple(String, Array(Map(String, LowCardinality(UInt64))));), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x000000000a06b56b 4. /build/src/Interpreters/parseColumnsListForTableFunction.cpp:67: DB::validateDataType(std::shared_ptr const&, DB::DataTypeValidationSettings const&)::$_0::operator()(DB::IDataType const&) const @ 0x0000000014ccea0b 5. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000013bf3d4b 6. /build/src/DataTypes/DataTypeTuple.cpp:413: DB::DataTypeTuple::forEachChild(std::function const&) const @ 0x0000000013c0b675 7. /build/src/Interpreters/parseColumnsListForTableFunction.cpp:173: DB::validateDataType(std::shared_ptr const&, DB::DataTypeValidationSettings const&) @ 0x0000000014ccde2d 8. /build/src/Functions/CastOverloadResolver.cpp:128: DB::CastOverloadResolverImpl::getReturnTypeImpl(std::vector> const&) const @ 0x0000000012dcd4a5 9. /build/src/Functions/IFunction.cpp:645: DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x0000000012d96b0c 10. /build/src/Functions/IFunction.cpp:585: DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x0000000012d9665b 11. /build/src/Functions/IFunction.cpp:606: DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x0000000012d96edc 12. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3544: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000014033cc9 13. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3838: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000014019a9e 14. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3980: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000014018e31 15. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:4304: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000014042fa7 16. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5605: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000014013749 17. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000140127f9 18. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000014011fce 19. /build/src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000001406ce8a 20. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000014973b42 21. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000001497268d 22. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000014974d24 23. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001492924b 24. /build/src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88641 25. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 26. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 27. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 28. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 29. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 30. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 31. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 2025.07.28 11:51:32.440540 [ 4581 ] {} 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(('a', [map('b', 42)]), 'Tuple(String, Array(Map(String, LowCardinality(UInt64))))'). (SUSPICIOUS_TYPE_FOR_LOW_CARDINALITY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x000000000a06b56b 4. /build/src/Interpreters/parseColumnsListForTableFunction.cpp:67: DB::validateDataType(std::shared_ptr const&, DB::DataTypeValidationSettings const&)::$_0::operator()(DB::IDataType const&) const @ 0x0000000014ccea0b 5. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000013bf3d4b 6. /build/src/DataTypes/DataTypeTuple.cpp:413: DB::DataTypeTuple::forEachChild(std::function const&) const @ 0x0000000013c0b675 7. /build/src/Interpreters/parseColumnsListForTableFunction.cpp:173: DB::validateDataType(std::shared_ptr const&, DB::DataTypeValidationSettings const&) @ 0x0000000014ccde2d 8. /build/src/Functions/CastOverloadResolver.cpp:128: DB::CastOverloadResolverImpl::getReturnTypeImpl(std::vector> const&) const @ 0x0000000012dcd4a5 9. /build/src/Functions/IFunction.cpp:645: DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x0000000012d96b0c 10. /build/src/Functions/IFunction.cpp:585: DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x0000000012d9665b 11. /build/src/Functions/IFunction.cpp:606: DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x0000000012d96edc 12. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3544: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000014033cc9 13. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3838: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000014019a9e 14. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3980: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000014018e31 15. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:4304: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000014042fa7 16. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5605: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000014013749 17. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000140127f9 18. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000014011fce 19. /build/src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000001406ce8a 20. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000014973b42 21. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000001497268d 22. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000014974d24 23. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001492924b 24. /build/src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88641 25. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 26. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 27. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 28. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 29. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 30. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 31. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 2025.07.28 11:51:32.596666 [ 4581 ] {2dcc05de-341d-4d5b-aebc-ea0c59296bd6} 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.6.10636.altinitytest (altinity build)) (from [::1]:33012) (comment: 02981_nested_bad_types.sql) (query 10, line 13) (in query: create table test (x Array(LowCardinality(UInt64))) engine=Memory;), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x000000000a06b56b 4. /build/src/Interpreters/parseColumnsListForTableFunction.cpp:67: DB::validateDataType(std::shared_ptr const&, DB::DataTypeValidationSettings const&)::$_0::operator()(DB::IDataType const&) const @ 0x0000000014ccea0b 5. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000013bd9034 6. /build/src/Interpreters/parseColumnsListForTableFunction.cpp:173: DB::validateDataType(std::shared_ptr const&, DB::DataTypeValidationSettings const&) @ 0x0000000014ccde2d 7. /build/src/Interpreters/InterpreterCreateQuery.cpp:1037: DB::InterpreterCreateQuery::validateTableStructure(DB::ASTCreateQuery const&, DB::InterpreterCreateQuery::TableProperties const&) const @ 0x00000000148f3cdc 8. /build/src/Interpreters/InterpreterCreateQuery.cpp:1007: DB::InterpreterCreateQuery::getTablePropertiesAndNormalizeCreateQuery(DB::ASTCreateQuery&, DB::LoadingStrictnessLevel) const @ 0x00000000148f0ec3 9. /build/src/Interpreters/InterpreterCreateQuery.cpp:1657: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000148f901b 10. /build/src/Interpreters/InterpreterCreateQuery.cpp:2352: DB::InterpreterCreateQuery::execute() @ 0x0000000014905a41 11. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88dc9 12. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 13. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 14. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 15. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 16. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 17. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 18. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 19. ? @ 0x00007fbc6213eac3 20. ? @ 0x00007fbc621d0850 2025.07.28 11:51:32.601089 [ 4581 ] {} 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. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x000000000a06b56b 4. /build/src/Interpreters/parseColumnsListForTableFunction.cpp:67: DB::validateDataType(std::shared_ptr const&, DB::DataTypeValidationSettings const&)::$_0::operator()(DB::IDataType const&) const @ 0x0000000014ccea0b 5. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000013bd9034 6. /build/src/Interpreters/parseColumnsListForTableFunction.cpp:173: DB::validateDataType(std::shared_ptr const&, DB::DataTypeValidationSettings const&) @ 0x0000000014ccde2d 7. /build/src/Interpreters/InterpreterCreateQuery.cpp:1037: DB::InterpreterCreateQuery::validateTableStructure(DB::ASTCreateQuery const&, DB::InterpreterCreateQuery::TableProperties const&) const @ 0x00000000148f3cdc 8. /build/src/Interpreters/InterpreterCreateQuery.cpp:1007: DB::InterpreterCreateQuery::getTablePropertiesAndNormalizeCreateQuery(DB::ASTCreateQuery&, DB::LoadingStrictnessLevel) const @ 0x00000000148f0ec3 9. /build/src/Interpreters/InterpreterCreateQuery.cpp:1657: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000148f901b 10. /build/src/Interpreters/InterpreterCreateQuery.cpp:2352: DB::InterpreterCreateQuery::execute() @ 0x0000000014905a41 11. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88dc9 12. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 13. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 14. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 15. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 16. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 17. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 18. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 19. ? @ 0x00007fbc6213eac3 20. ? @ 0x00007fbc621d0850 2025.07.28 11:51:32.670868 [ 4581 ] {3e03082a-e65b-4c12-b6e7-9c3aacdcadb5} 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.6.10636.altinitytest (altinity build)) (from [::1]:33012) (comment: 02981_nested_bad_types.sql) (query 11, line 14) (in query: create table test (x Array(Array(LowCardinality(UInt64)))) engine=Memory;), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x000000000a06b56b 4. /build/src/Interpreters/parseColumnsListForTableFunction.cpp:67: DB::validateDataType(std::shared_ptr const&, DB::DataTypeValidationSettings const&)::$_0::operator()(DB::IDataType const&) const @ 0x0000000014ccea0b 5. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000013bd9034 6. /build/src/Interpreters/parseColumnsListForTableFunction.cpp:173: DB::validateDataType(std::shared_ptr const&, DB::DataTypeValidationSettings const&) @ 0x0000000014ccde2d 7. /build/src/Interpreters/InterpreterCreateQuery.cpp:1037: DB::InterpreterCreateQuery::validateTableStructure(DB::ASTCreateQuery const&, DB::InterpreterCreateQuery::TableProperties const&) const @ 0x00000000148f3cdc 8. /build/src/Interpreters/InterpreterCreateQuery.cpp:1007: DB::InterpreterCreateQuery::getTablePropertiesAndNormalizeCreateQuery(DB::ASTCreateQuery&, DB::LoadingStrictnessLevel) const @ 0x00000000148f0ec3 9. /build/src/Interpreters/InterpreterCreateQuery.cpp:1657: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000148f901b 10. /build/src/Interpreters/InterpreterCreateQuery.cpp:2352: DB::InterpreterCreateQuery::execute() @ 0x0000000014905a41 11. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88dc9 12. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 13. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 14. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 15. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 16. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 17. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 18. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 19. ? @ 0x00007fbc6213eac3 20. ? @ 0x00007fbc621d0850 2025.07.28 11:51:32.675521 [ 4581 ] {} 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. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x000000000a06b56b 4. /build/src/Interpreters/parseColumnsListForTableFunction.cpp:67: DB::validateDataType(std::shared_ptr const&, DB::DataTypeValidationSettings const&)::$_0::operator()(DB::IDataType const&) const @ 0x0000000014ccea0b 5. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000013bd9034 6. /build/src/Interpreters/parseColumnsListForTableFunction.cpp:173: DB::validateDataType(std::shared_ptr const&, DB::DataTypeValidationSettings const&) @ 0x0000000014ccde2d 7. /build/src/Interpreters/InterpreterCreateQuery.cpp:1037: DB::InterpreterCreateQuery::validateTableStructure(DB::ASTCreateQuery const&, DB::InterpreterCreateQuery::TableProperties const&) const @ 0x00000000148f3cdc 8. /build/src/Interpreters/InterpreterCreateQuery.cpp:1007: DB::InterpreterCreateQuery::getTablePropertiesAndNormalizeCreateQuery(DB::ASTCreateQuery&, DB::LoadingStrictnessLevel) const @ 0x00000000148f0ec3 9. /build/src/Interpreters/InterpreterCreateQuery.cpp:1657: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000148f901b 10. /build/src/Interpreters/InterpreterCreateQuery.cpp:2352: DB::InterpreterCreateQuery::execute() @ 0x0000000014905a41 11. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88dc9 12. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 13. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 14. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 15. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 16. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 17. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 18. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 19. ? @ 0x00007fbc6213eac3 20. ? @ 0x00007fbc621d0850 2025.07.28 11:51:32.793234 [ 4581 ] {d0bdad1a-28b4-48ef-9b76-12a4e3439b11} 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.6.10636.altinitytest (altinity build)) (from [::1]:33012) (comment: 02981_nested_bad_types.sql) (query 12, line 15) (in query: create table test (x Map(String, LowCardinality(UInt64))) engine=Memory;), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x000000000a06b56b 4. /build/src/Interpreters/parseColumnsListForTableFunction.cpp:67: DB::validateDataType(std::shared_ptr const&, DB::DataTypeValidationSettings const&)::$_0::operator()(DB::IDataType const&) const @ 0x0000000014ccea0b 5. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000013bf3d4b 6. /build/src/Interpreters/parseColumnsListForTableFunction.cpp:173: DB::validateDataType(std::shared_ptr const&, DB::DataTypeValidationSettings const&) @ 0x0000000014ccde2d 7. /build/src/Interpreters/InterpreterCreateQuery.cpp:1037: DB::InterpreterCreateQuery::validateTableStructure(DB::ASTCreateQuery const&, DB::InterpreterCreateQuery::TableProperties const&) const @ 0x00000000148f3cdc 8. /build/src/Interpreters/InterpreterCreateQuery.cpp:1007: DB::InterpreterCreateQuery::getTablePropertiesAndNormalizeCreateQuery(DB::ASTCreateQuery&, DB::LoadingStrictnessLevel) const @ 0x00000000148f0ec3 9. /build/src/Interpreters/InterpreterCreateQuery.cpp:1657: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000148f901b 10. /build/src/Interpreters/InterpreterCreateQuery.cpp:2352: DB::InterpreterCreateQuery::execute() @ 0x0000000014905a41 11. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88dc9 12. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 13. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 14. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 15. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 16. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 17. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 18. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 19. ? @ 0x00007fbc6213eac3 20. ? @ 0x00007fbc621d0850 2025.07.28 11:51:32.804310 [ 4581 ] {} 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. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x000000000a06b56b 4. /build/src/Interpreters/parseColumnsListForTableFunction.cpp:67: DB::validateDataType(std::shared_ptr const&, DB::DataTypeValidationSettings const&)::$_0::operator()(DB::IDataType const&) const @ 0x0000000014ccea0b 5. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000013bf3d4b 6. /build/src/Interpreters/parseColumnsListForTableFunction.cpp:173: DB::validateDataType(std::shared_ptr const&, DB::DataTypeValidationSettings const&) @ 0x0000000014ccde2d 7. /build/src/Interpreters/InterpreterCreateQuery.cpp:1037: DB::InterpreterCreateQuery::validateTableStructure(DB::ASTCreateQuery const&, DB::InterpreterCreateQuery::TableProperties const&) const @ 0x00000000148f3cdc 8. /build/src/Interpreters/InterpreterCreateQuery.cpp:1007: DB::InterpreterCreateQuery::getTablePropertiesAndNormalizeCreateQuery(DB::ASTCreateQuery&, DB::LoadingStrictnessLevel) const @ 0x00000000148f0ec3 9. /build/src/Interpreters/InterpreterCreateQuery.cpp:1657: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000148f901b 10. /build/src/Interpreters/InterpreterCreateQuery.cpp:2352: DB::InterpreterCreateQuery::execute() @ 0x0000000014905a41 11. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88dc9 12. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 13. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 14. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 15. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 16. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 17. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 18. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 19. ? @ 0x00007fbc6213eac3 20. ? @ 0x00007fbc621d0850 2025.07.28 11:51:32.835398 [ 4581 ] {01581dcf-d45e-40be-bbdb-a34ada6d7981} 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.6.10636.altinitytest (altinity build)) (from [::1]:33012) (comment: 02981_nested_bad_types.sql) (query 13, line 16) (in query: create table test (x Map(String, Map(String, LowCardinality(UInt64)))) engine=Memory;), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x000000000a06b56b 4. /build/src/Interpreters/parseColumnsListForTableFunction.cpp:67: DB::validateDataType(std::shared_ptr const&, DB::DataTypeValidationSettings const&)::$_0::operator()(DB::IDataType const&) const @ 0x0000000014ccea0b 5. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000013bf3d4b 6. /build/src/Interpreters/parseColumnsListForTableFunction.cpp:173: DB::validateDataType(std::shared_ptr const&, DB::DataTypeValidationSettings const&) @ 0x0000000014ccde2d 7. /build/src/Interpreters/InterpreterCreateQuery.cpp:1037: DB::InterpreterCreateQuery::validateTableStructure(DB::ASTCreateQuery const&, DB::InterpreterCreateQuery::TableProperties const&) const @ 0x00000000148f3cdc 8. /build/src/Interpreters/InterpreterCreateQuery.cpp:1007: DB::InterpreterCreateQuery::getTablePropertiesAndNormalizeCreateQuery(DB::ASTCreateQuery&, DB::LoadingStrictnessLevel) const @ 0x00000000148f0ec3 9. /build/src/Interpreters/InterpreterCreateQuery.cpp:1657: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000148f901b 10. /build/src/Interpreters/InterpreterCreateQuery.cpp:2352: DB::InterpreterCreateQuery::execute() @ 0x0000000014905a41 11. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88dc9 12. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 13. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 14. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 15. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 16. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 17. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 18. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 19. ? @ 0x00007fbc6213eac3 20. ? @ 0x00007fbc621d0850 2025.07.28 11:51:32.839966 [ 4581 ] {} 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. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x000000000a06b56b 4. /build/src/Interpreters/parseColumnsListForTableFunction.cpp:67: DB::validateDataType(std::shared_ptr const&, DB::DataTypeValidationSettings const&)::$_0::operator()(DB::IDataType const&) const @ 0x0000000014ccea0b 5. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000013bf3d4b 6. /build/src/Interpreters/parseColumnsListForTableFunction.cpp:173: DB::validateDataType(std::shared_ptr const&, DB::DataTypeValidationSettings const&) @ 0x0000000014ccde2d 7. /build/src/Interpreters/InterpreterCreateQuery.cpp:1037: DB::InterpreterCreateQuery::validateTableStructure(DB::ASTCreateQuery const&, DB::InterpreterCreateQuery::TableProperties const&) const @ 0x00000000148f3cdc 8. /build/src/Interpreters/InterpreterCreateQuery.cpp:1007: DB::InterpreterCreateQuery::getTablePropertiesAndNormalizeCreateQuery(DB::ASTCreateQuery&, DB::LoadingStrictnessLevel) const @ 0x00000000148f0ec3 9. /build/src/Interpreters/InterpreterCreateQuery.cpp:1657: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000148f901b 10. /build/src/Interpreters/InterpreterCreateQuery.cpp:2352: DB::InterpreterCreateQuery::execute() @ 0x0000000014905a41 11. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88dc9 12. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 13. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 14. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 15. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 16. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 17. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 18. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 19. ? @ 0x00007fbc6213eac3 20. ? @ 0x00007fbc621d0850 2025.07.28 11:51:32.843659 [ 4900 ] {22ce7dee-2d95-45d3-96bc-f2ea99b25139} executeQuery: Code: 57. DB::Exception: Table test_5.type_json_dst already exists. (TABLE_ALREADY_EXISTS) (version 25.3.6.10636.altinitytest (altinity build)) (from 0.0.0.0:0) (comment: 01825_new_type_json_insert_select.sql) (in query: /* ddl_entry=query-0000000039 */ CREATE TABLE test_5.type_json_dst UUID '5c82afd5-6623-40a6-b95b-22258455657f' (`data` JSON) ENGINE = MergeTree ORDER BY tuple() SETTINGS index_granularity = 55870, min_bytes_for_wide_part = 1073741824, 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 = 350638029, compact_parts_max_granules_to_buffer = 256, compact_parts_merge_max_bytes_to_prefetch_part = 18723216, merge_max_block_size = 15311, old_parts_lifetime = 247., prefer_fetch_merged_part_size_threshold = 10737418240, vertical_merge_algorithm_min_rows_to_activate = 848904, vertical_merge_algorithm_min_columns_to_activate = 90, min_merge_bytes_to_use_direct_io = 10737418240, index_granularity_bytes = 5790717, use_const_adaptive_granularity = true, enable_index_granularity_compression = true, concurrent_part_removal_threshold = 11, 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 = 35947, primary_key_compress_block_size = 91043, 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. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000a06a8eb 4. /build/src/Interpreters/InterpreterCreateQuery.cpp:1824: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x0000000014901d53 5. /build/src/Interpreters/InterpreterCreateQuery.cpp:1743: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000148f9aa9 6. /build/src/Interpreters/InterpreterCreateQuery.cpp:2352: DB::InterpreterCreateQuery::execute() @ 0x0000000014905a41 7. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88dc9 8. /build/src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x0000000014c8ca7b 9. /build/src/Interpreters/DDLWorker.cpp:510: DB::DDLWorker::tryExecuteQuery(DB::DDLTaskBase&, std::shared_ptr const&, bool) @ 0x00000000144dab9e 10. /build/src/Interpreters/DDLWorker.cpp:675: DB::DDLWorker::processTask(DB::DDLTaskBase&, std::shared_ptr const&, bool) @ 0x00000000144d8ffe 11. /build/src/Databases/DatabaseReplicatedWorker.cpp:372: DB::DatabaseReplicatedDDLWorker::tryEnqueueAndExecuteEntry(DB::DDLLogEntry&, std::shared_ptr, bool) @ 0x0000000013dc29ab 12. /build/src/Databases/DatabaseReplicated.cpp:1139: DB::DatabaseReplicated::tryEnqueueReplicatedDDL(std::shared_ptr const&, std::shared_ptr, DB::QueryFlags) @ 0x0000000013d9f73c 13. /build/src/Interpreters/InterpreterCreateQuery.cpp:1723: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000148f96f8 14. /build/src/Interpreters/InterpreterCreateQuery.cpp:2352: DB::InterpreterCreateQuery::execute() @ 0x0000000014905a41 15. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88dc9 16. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 17. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 18. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 19. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 20. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 21. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 22. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 23. ? @ 0x00007fbc6213eac3 24. ? @ 0x00007fbc621d0850 2025.07.28 11:51:32.892564 [ 4900 ] {22ce7dee-2d95-45d3-96bc-f2ea99b25139} executeQuery: Code: 57. DB::Exception: Table test_5.type_json_dst already exists. (TABLE_ALREADY_EXISTS) (version 25.3.6.10636.altinitytest (altinity build)) (from [::1]:47268) (comment: 01825_new_type_json_insert_select.sql) (query 27, line 45) (in query: CREATE TABLE type_json_dst (`data` JSON) ENGINE = MergeTree ORDER BY tuple() SETTINGS index_granularity = 55870, min_bytes_for_wide_part = 1073741824, 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 = 350638029, compact_parts_max_granules_to_buffer = 256, compact_parts_merge_max_bytes_to_prefetch_part = 18723216, merge_max_block_size = 15311, old_parts_lifetime = 247., prefer_fetch_merged_part_size_threshold = 10737418240, vertical_merge_algorithm_min_rows_to_activate = 848904, vertical_merge_algorithm_min_columns_to_activate = 90, min_merge_bytes_to_use_direct_io = 10737418240, index_granularity_bytes = 5790717, use_const_adaptive_granularity = true, enable_index_granularity_compression = true, concurrent_part_removal_threshold = 11, 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 = 35947, primary_key_compress_block_size = 91043, 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. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000a06a8eb 4. /build/src/Interpreters/InterpreterCreateQuery.cpp:1824: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x0000000014901d53 5. /build/src/Interpreters/InterpreterCreateQuery.cpp:1743: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000148f9aa9 6. /build/src/Interpreters/InterpreterCreateQuery.cpp:2352: DB::InterpreterCreateQuery::execute() @ 0x0000000014905a41 7. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88dc9 8. /build/src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x0000000014c8ca7b 9. /build/src/Interpreters/DDLWorker.cpp:510: DB::DDLWorker::tryExecuteQuery(DB::DDLTaskBase&, std::shared_ptr const&, bool) @ 0x00000000144dab9e 10. /build/src/Interpreters/DDLWorker.cpp:675: DB::DDLWorker::processTask(DB::DDLTaskBase&, std::shared_ptr const&, bool) @ 0x00000000144d8ffe 11. /build/src/Databases/DatabaseReplicatedWorker.cpp:372: DB::DatabaseReplicatedDDLWorker::tryEnqueueAndExecuteEntry(DB::DDLLogEntry&, std::shared_ptr, bool) @ 0x0000000013dc29ab 12. /build/src/Databases/DatabaseReplicated.cpp:1139: DB::DatabaseReplicated::tryEnqueueReplicatedDDL(std::shared_ptr const&, std::shared_ptr, DB::QueryFlags) @ 0x0000000013d9f73c 13. /build/src/Interpreters/InterpreterCreateQuery.cpp:1723: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000148f96f8 14. /build/src/Interpreters/InterpreterCreateQuery.cpp:2352: DB::InterpreterCreateQuery::execute() @ 0x0000000014905a41 15. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88dc9 16. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 17. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 18. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 19. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 20. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 21. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 22. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 23. ? @ 0x00007fbc6213eac3 24. ? @ 0x00007fbc621d0850 2025.07.28 11:51:32.901817 [ 4900 ] {} TCPHandler: Code: 57. DB::Exception: Table test_5.type_json_dst already exists. (TABLE_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000a06a8eb 4. /build/src/Interpreters/InterpreterCreateQuery.cpp:1824: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x0000000014901d53 5. /build/src/Interpreters/InterpreterCreateQuery.cpp:1743: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000148f9aa9 6. /build/src/Interpreters/InterpreterCreateQuery.cpp:2352: DB::InterpreterCreateQuery::execute() @ 0x0000000014905a41 7. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88dc9 8. /build/src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x0000000014c8ca7b 9. /build/src/Interpreters/DDLWorker.cpp:510: DB::DDLWorker::tryExecuteQuery(DB::DDLTaskBase&, std::shared_ptr const&, bool) @ 0x00000000144dab9e 10. /build/src/Interpreters/DDLWorker.cpp:675: DB::DDLWorker::processTask(DB::DDLTaskBase&, std::shared_ptr const&, bool) @ 0x00000000144d8ffe 11. /build/src/Databases/DatabaseReplicatedWorker.cpp:372: DB::DatabaseReplicatedDDLWorker::tryEnqueueAndExecuteEntry(DB::DDLLogEntry&, std::shared_ptr, bool) @ 0x0000000013dc29ab 12. /build/src/Databases/DatabaseReplicated.cpp:1139: DB::DatabaseReplicated::tryEnqueueReplicatedDDL(std::shared_ptr const&, std::shared_ptr, DB::QueryFlags) @ 0x0000000013d9f73c 13. /build/src/Interpreters/InterpreterCreateQuery.cpp:1723: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000148f96f8 14. /build/src/Interpreters/InterpreterCreateQuery.cpp:2352: DB::InterpreterCreateQuery::execute() @ 0x0000000014905a41 15. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88dc9 16. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 17. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 18. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 19. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 20. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 21. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 22. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 23. ? @ 0x00007fbc6213eac3 24. ? @ 0x00007fbc621d0850 2025.07.28 11:51:32.982260 [ 4581 ] {ae8c1faf-0625-4d7f-a94d-7accf690fe48} 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.6.10636.altinitytest (altinity build)) (from [::1]:33012) (comment: 02981_nested_bad_types.sql) (query 14, line 17) (in query: create table test (x Tuple(String, LowCardinality(UInt64))) engine=Memory;), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x000000000a06b56b 4. /build/src/Interpreters/parseColumnsListForTableFunction.cpp:67: DB::validateDataType(std::shared_ptr const&, DB::DataTypeValidationSettings const&)::$_0::operator()(DB::IDataType const&) const @ 0x0000000014ccea0b 5. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000013c0b669 6. /build/src/Interpreters/parseColumnsListForTableFunction.cpp:173: DB::validateDataType(std::shared_ptr const&, DB::DataTypeValidationSettings const&) @ 0x0000000014ccde2d 7. /build/src/Interpreters/InterpreterCreateQuery.cpp:1037: DB::InterpreterCreateQuery::validateTableStructure(DB::ASTCreateQuery const&, DB::InterpreterCreateQuery::TableProperties const&) const @ 0x00000000148f3cdc 8. /build/src/Interpreters/InterpreterCreateQuery.cpp:1007: DB::InterpreterCreateQuery::getTablePropertiesAndNormalizeCreateQuery(DB::ASTCreateQuery&, DB::LoadingStrictnessLevel) const @ 0x00000000148f0ec3 9. /build/src/Interpreters/InterpreterCreateQuery.cpp:1657: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000148f901b 10. /build/src/Interpreters/InterpreterCreateQuery.cpp:2352: DB::InterpreterCreateQuery::execute() @ 0x0000000014905a41 11. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88dc9 12. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 13. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 14. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 15. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 16. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 17. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 18. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 19. ? @ 0x00007fbc6213eac3 20. ? @ 0x00007fbc621d0850 2025.07.28 11:51:32.986257 [ 4581 ] {} 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. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x000000000a06b56b 4. /build/src/Interpreters/parseColumnsListForTableFunction.cpp:67: DB::validateDataType(std::shared_ptr const&, DB::DataTypeValidationSettings const&)::$_0::operator()(DB::IDataType const&) const @ 0x0000000014ccea0b 5. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000013c0b669 6. /build/src/Interpreters/parseColumnsListForTableFunction.cpp:173: DB::validateDataType(std::shared_ptr const&, DB::DataTypeValidationSettings const&) @ 0x0000000014ccde2d 7. /build/src/Interpreters/InterpreterCreateQuery.cpp:1037: DB::InterpreterCreateQuery::validateTableStructure(DB::ASTCreateQuery const&, DB::InterpreterCreateQuery::TableProperties const&) const @ 0x00000000148f3cdc 8. /build/src/Interpreters/InterpreterCreateQuery.cpp:1007: DB::InterpreterCreateQuery::getTablePropertiesAndNormalizeCreateQuery(DB::ASTCreateQuery&, DB::LoadingStrictnessLevel) const @ 0x00000000148f0ec3 9. /build/src/Interpreters/InterpreterCreateQuery.cpp:1657: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000148f901b 10. /build/src/Interpreters/InterpreterCreateQuery.cpp:2352: DB::InterpreterCreateQuery::execute() @ 0x0000000014905a41 11. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88dc9 12. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 13. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 14. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 15. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 16. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 17. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 18. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 19. ? @ 0x00007fbc6213eac3 20. ? @ 0x00007fbc621d0850 2025.07.28 11:51:33.086450 [ 4581 ] {8950d07d-fa7d-4782-ab7a-c9c3001ad01f} 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.6.10636.altinitytest (altinity build)) (from [::1]:33012) (comment: 02981_nested_bad_types.sql) (query 15, line 18) (in query: create table test (x Tuple(String, Array(Map(String, LowCardinality(UInt64))))) engine=Memory;), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x000000000a06b56b 4. /build/src/Interpreters/parseColumnsListForTableFunction.cpp:67: DB::validateDataType(std::shared_ptr const&, DB::DataTypeValidationSettings const&)::$_0::operator()(DB::IDataType const&) const @ 0x0000000014ccea0b 5. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000013bf3d4b 6. /build/src/DataTypes/DataTypeTuple.cpp:413: DB::DataTypeTuple::forEachChild(std::function const&) const @ 0x0000000013c0b675 7. /build/src/Interpreters/parseColumnsListForTableFunction.cpp:173: DB::validateDataType(std::shared_ptr const&, DB::DataTypeValidationSettings const&) @ 0x0000000014ccde2d 8. /build/src/Interpreters/InterpreterCreateQuery.cpp:1037: DB::InterpreterCreateQuery::validateTableStructure(DB::ASTCreateQuery const&, DB::InterpreterCreateQuery::TableProperties const&) const @ 0x00000000148f3cdc 9. /build/src/Interpreters/InterpreterCreateQuery.cpp:1007: DB::InterpreterCreateQuery::getTablePropertiesAndNormalizeCreateQuery(DB::ASTCreateQuery&, DB::LoadingStrictnessLevel) const @ 0x00000000148f0ec3 10. /build/src/Interpreters/InterpreterCreateQuery.cpp:1657: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000148f901b 11. /build/src/Interpreters/InterpreterCreateQuery.cpp:2352: DB::InterpreterCreateQuery::execute() @ 0x0000000014905a41 12. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88dc9 13. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 14. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 15. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 16. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 17. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 18. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 19. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 20. ? @ 0x00007fbc6213eac3 21. ? @ 0x00007fbc621d0850 2025.07.28 11:51:33.119880 [ 4581 ] {} 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. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x000000000a06b56b 4. /build/src/Interpreters/parseColumnsListForTableFunction.cpp:67: DB::validateDataType(std::shared_ptr const&, DB::DataTypeValidationSettings const&)::$_0::operator()(DB::IDataType const&) const @ 0x0000000014ccea0b 5. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000013bf3d4b 6. /build/src/DataTypes/DataTypeTuple.cpp:413: DB::DataTypeTuple::forEachChild(std::function const&) const @ 0x0000000013c0b675 7. /build/src/Interpreters/parseColumnsListForTableFunction.cpp:173: DB::validateDataType(std::shared_ptr const&, DB::DataTypeValidationSettings const&) @ 0x0000000014ccde2d 8. /build/src/Interpreters/InterpreterCreateQuery.cpp:1037: DB::InterpreterCreateQuery::validateTableStructure(DB::ASTCreateQuery const&, DB::InterpreterCreateQuery::TableProperties const&) const @ 0x00000000148f3cdc 9. /build/src/Interpreters/InterpreterCreateQuery.cpp:1007: DB::InterpreterCreateQuery::getTablePropertiesAndNormalizeCreateQuery(DB::ASTCreateQuery&, DB::LoadingStrictnessLevel) const @ 0x00000000148f0ec3 10. /build/src/Interpreters/InterpreterCreateQuery.cpp:1657: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000148f901b 11. /build/src/Interpreters/InterpreterCreateQuery.cpp:2352: DB::InterpreterCreateQuery::execute() @ 0x0000000014905a41 12. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88dc9 13. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 14. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 15. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 16. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 17. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 18. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 19. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 20. ? @ 0x00007fbc6213eac3 21. ? @ 0x00007fbc621d0850 2025.07.28 11:51:33.354490 [ 4581 ] {cee02d28-168a-4ddf-878c-db1023dfb2e2} executeQuery: Code: 44. DB::Exception: Cannot create column with type 'FixedString(1000000)' 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('[\'42\']', 'Array(FixedString(1000000))'). (ILLEGAL_COLUMN) (version 25.3.6.10636.altinitytest (altinity build)) (from [::1]:33012) (comment: 02981_nested_bad_types.sql) (query 16, line 21) (in query: select ['42']::Array(FixedString(1000000));), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, unsigned long const&) @ 0x000000000a3d916b 4. /build/src/Interpreters/parseColumnsListForTableFunction.cpp:92: DB::validateDataType(std::shared_ptr const&, DB::DataTypeValidationSettings const&)::$_0::operator()(DB::IDataType const&) const @ 0x0000000014cce8bf 5. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000013bd9034 6. /build/src/Interpreters/parseColumnsListForTableFunction.cpp:173: DB::validateDataType(std::shared_ptr const&, DB::DataTypeValidationSettings const&) @ 0x0000000014ccde2d 7. /build/src/Functions/CastOverloadResolver.cpp:128: DB::CastOverloadResolverImpl::getReturnTypeImpl(std::vector> const&) const @ 0x0000000012dcd4a5 8. /build/src/Functions/IFunction.cpp:645: DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x0000000012d96b0c 9. /build/src/Functions/IFunction.cpp:585: DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x0000000012d9665b 10. /build/src/Functions/IFunction.cpp:606: DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x0000000012d96edc 11. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3544: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000014033cc9 12. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3838: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000014019a9e 13. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3980: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000014018e31 14. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:4304: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000014042fa7 15. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5605: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000014013749 16. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000140127f9 17. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000014011fce 18. /build/src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000001406ce8a 19. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000014973b42 20. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000001497268d 21. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000014974d24 22. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001492924b 23. /build/src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88641 24. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 25. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 26. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 27. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 28. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 29. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 30. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 31. ? @ 0x00007fbc6213eac3 2025.07.28 11:51:33.357947 [ 4581 ] {} TCPHandler: Code: 44. DB::Exception: Cannot create column with type 'FixedString(1000000)' 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('[\'42\']', 'Array(FixedString(1000000))'). (ILLEGAL_COLUMN), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, unsigned long const&) @ 0x000000000a3d916b 4. /build/src/Interpreters/parseColumnsListForTableFunction.cpp:92: DB::validateDataType(std::shared_ptr const&, DB::DataTypeValidationSettings const&)::$_0::operator()(DB::IDataType const&) const @ 0x0000000014cce8bf 5. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000013bd9034 6. /build/src/Interpreters/parseColumnsListForTableFunction.cpp:173: DB::validateDataType(std::shared_ptr const&, DB::DataTypeValidationSettings const&) @ 0x0000000014ccde2d 7. /build/src/Functions/CastOverloadResolver.cpp:128: DB::CastOverloadResolverImpl::getReturnTypeImpl(std::vector> const&) const @ 0x0000000012dcd4a5 8. /build/src/Functions/IFunction.cpp:645: DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x0000000012d96b0c 9. /build/src/Functions/IFunction.cpp:585: DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x0000000012d9665b 10. /build/src/Functions/IFunction.cpp:606: DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x0000000012d96edc 11. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3544: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000014033cc9 12. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3838: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000014019a9e 13. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3980: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000014018e31 14. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:4304: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000014042fa7 15. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5605: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000014013749 16. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000140127f9 17. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000014011fce 18. /build/src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000001406ce8a 19. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000014973b42 20. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000001497268d 21. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000014974d24 22. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001492924b 23. /build/src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88641 24. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 25. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 26. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 27. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 28. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 29. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 30. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 31. ? @ 0x00007fbc6213eac3 2025.07.28 11:51:33.401167 [ 4581 ] {34d2f088-9b92-494e-b467-ce97e3d364b8} executeQuery: Code: 44. DB::Exception: Cannot create column with type 'FixedString(1000000)' 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('[\'42\']', 'Array(FixedString(1000000))'). (ILLEGAL_COLUMN) (version 25.3.6.10636.altinitytest (altinity build)) (from [::1]:33012) (comment: 02981_nested_bad_types.sql) (query 17, line 22) (in query: select ['42']::Array(FixedString(1000000));), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, unsigned long const&) @ 0x000000000a3d916b 4. /build/src/Interpreters/parseColumnsListForTableFunction.cpp:92: DB::validateDataType(std::shared_ptr const&, DB::DataTypeValidationSettings const&)::$_0::operator()(DB::IDataType const&) const @ 0x0000000014cce8bf 5. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000013bd9034 6. /build/src/Interpreters/parseColumnsListForTableFunction.cpp:173: DB::validateDataType(std::shared_ptr const&, DB::DataTypeValidationSettings const&) @ 0x0000000014ccde2d 7. /build/src/Functions/CastOverloadResolver.cpp:128: DB::CastOverloadResolverImpl::getReturnTypeImpl(std::vector> const&) const @ 0x0000000012dcd4a5 8. /build/src/Functions/IFunction.cpp:645: DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x0000000012d96b0c 9. /build/src/Functions/IFunction.cpp:585: DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x0000000012d9665b 10. /build/src/Functions/IFunction.cpp:606: DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x0000000012d96edc 11. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3544: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000014033cc9 12. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3838: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000014019a9e 13. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3980: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000014018e31 14. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:4304: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000014042fa7 15. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5605: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000014013749 16. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000140127f9 17. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000014011fce 18. /build/src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000001406ce8a 19. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000014973b42 20. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000001497268d 21. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000014974d24 22. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001492924b 23. /build/src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88641 24. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 25. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 26. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 27. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 28. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 29. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 30. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 31. ? @ 0x00007fbc6213eac3 2025.07.28 11:51:33.417455 [ 4581 ] {} TCPHandler: Code: 44. DB::Exception: Cannot create column with type 'FixedString(1000000)' 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('[\'42\']', 'Array(FixedString(1000000))'). (ILLEGAL_COLUMN), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, unsigned long const&) @ 0x000000000a3d916b 4. /build/src/Interpreters/parseColumnsListForTableFunction.cpp:92: DB::validateDataType(std::shared_ptr const&, DB::DataTypeValidationSettings const&)::$_0::operator()(DB::IDataType const&) const @ 0x0000000014cce8bf 5. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000013bd9034 6. /build/src/Interpreters/parseColumnsListForTableFunction.cpp:173: DB::validateDataType(std::shared_ptr const&, DB::DataTypeValidationSettings const&) @ 0x0000000014ccde2d 7. /build/src/Functions/CastOverloadResolver.cpp:128: DB::CastOverloadResolverImpl::getReturnTypeImpl(std::vector> const&) const @ 0x0000000012dcd4a5 8. /build/src/Functions/IFunction.cpp:645: DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x0000000012d96b0c 9. /build/src/Functions/IFunction.cpp:585: DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x0000000012d9665b 10. /build/src/Functions/IFunction.cpp:606: DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x0000000012d96edc 11. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3544: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000014033cc9 12. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3838: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000014019a9e 13. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3980: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000014018e31 14. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:4304: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000014042fa7 15. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5605: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000014013749 16. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000140127f9 17. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000014011fce 18. /build/src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000001406ce8a 19. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000014973b42 20. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000001497268d 21. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000014974d24 22. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001492924b 23. /build/src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88641 24. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 25. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 26. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 27. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 28. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 29. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 30. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 31. ? @ 0x00007fbc6213eac3 2025.07.28 11:51:33.534009 [ 4581 ] {1d02f41c-6da3-4c99-9410-6a6f8db770a1} executeQuery: Code: 44. DB::Exception: Cannot create column with type 'FixedString(1000000)' 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('[[[\'42\']]]', 'Array(Array(Array(FixedString(1000000))))'). (ILLEGAL_COLUMN) (version 25.3.6.10636.altinitytest (altinity build)) (from [::1]:33012) (comment: 02981_nested_bad_types.sql) (query 18, line 23) (in query: select [[['42']]]::Array(Array(Array(FixedString(1000000))));), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, unsigned long const&) @ 0x000000000a3d916b 4. /build/src/Interpreters/parseColumnsListForTableFunction.cpp:92: DB::validateDataType(std::shared_ptr const&, DB::DataTypeValidationSettings const&)::$_0::operator()(DB::IDataType const&) const @ 0x0000000014cce8bf 5. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000013bd9034 6. /build/src/Interpreters/parseColumnsListForTableFunction.cpp:173: DB::validateDataType(std::shared_ptr const&, DB::DataTypeValidationSettings const&) @ 0x0000000014ccde2d 7. /build/src/Functions/CastOverloadResolver.cpp:128: DB::CastOverloadResolverImpl::getReturnTypeImpl(std::vector> const&) const @ 0x0000000012dcd4a5 8. /build/src/Functions/IFunction.cpp:645: DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x0000000012d96b0c 9. /build/src/Functions/IFunction.cpp:585: DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x0000000012d9665b 10. /build/src/Functions/IFunction.cpp:606: DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x0000000012d96edc 11. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3544: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000014033cc9 12. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3838: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000014019a9e 13. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3980: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000014018e31 14. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:4304: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000014042fa7 15. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5605: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000014013749 16. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000140127f9 17. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000014011fce 18. /build/src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000001406ce8a 19. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000014973b42 20. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000001497268d 21. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000014974d24 22. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001492924b 23. /build/src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88641 24. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 25. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 26. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 27. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 28. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 29. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 30. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 31. ? @ 0x00007fbc6213eac3 2025.07.28 11:51:33.554406 [ 4581 ] {} TCPHandler: Code: 44. DB::Exception: Cannot create column with type 'FixedString(1000000)' 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('[[[\'42\']]]', 'Array(Array(Array(FixedString(1000000))))'). (ILLEGAL_COLUMN), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, unsigned long const&) @ 0x000000000a3d916b 4. /build/src/Interpreters/parseColumnsListForTableFunction.cpp:92: DB::validateDataType(std::shared_ptr const&, DB::DataTypeValidationSettings const&)::$_0::operator()(DB::IDataType const&) const @ 0x0000000014cce8bf 5. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000013bd9034 6. /build/src/Interpreters/parseColumnsListForTableFunction.cpp:173: DB::validateDataType(std::shared_ptr const&, DB::DataTypeValidationSettings const&) @ 0x0000000014ccde2d 7. /build/src/Functions/CastOverloadResolver.cpp:128: DB::CastOverloadResolverImpl::getReturnTypeImpl(std::vector> const&) const @ 0x0000000012dcd4a5 8. /build/src/Functions/IFunction.cpp:645: DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x0000000012d96b0c 9. /build/src/Functions/IFunction.cpp:585: DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x0000000012d9665b 10. /build/src/Functions/IFunction.cpp:606: DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x0000000012d96edc 11. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3544: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000014033cc9 12. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3838: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000014019a9e 13. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3980: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000014018e31 14. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:4304: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000014042fa7 15. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5605: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000014013749 16. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000140127f9 17. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000014011fce 18. /build/src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000001406ce8a 19. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000014973b42 20. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000001497268d 21. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000014974d24 22. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001492924b 23. /build/src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88641 24. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 25. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 26. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 27. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 28. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 29. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 30. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 31. ? @ 0x00007fbc6213eac3 2025.07.28 11:51:33.717283 [ 4581 ] {1601f467-dfa7-467a-8afa-5524d84c9e01} executeQuery: Code: 44. DB::Exception: Cannot create column with type 'FixedString(1000000)' 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(map('a', '42'), 'Map(String, FixedString(1000000))'). (ILLEGAL_COLUMN) (version 25.3.6.10636.altinitytest (altinity build)) (from [::1]:33012) (comment: 02981_nested_bad_types.sql) (query 19, line 24) (in query: select map('a', '42')::Map(String, FixedString(1000000));), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, unsigned long const&) @ 0x000000000a3d916b 4. /build/src/Interpreters/parseColumnsListForTableFunction.cpp:92: DB::validateDataType(std::shared_ptr const&, DB::DataTypeValidationSettings const&)::$_0::operator()(DB::IDataType const&) const @ 0x0000000014cce8bf 5. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000013bf3d4b 6. /build/src/Interpreters/parseColumnsListForTableFunction.cpp:173: DB::validateDataType(std::shared_ptr const&, DB::DataTypeValidationSettings const&) @ 0x0000000014ccde2d 7. /build/src/Functions/CastOverloadResolver.cpp:128: DB::CastOverloadResolverImpl::getReturnTypeImpl(std::vector> const&) const @ 0x0000000012dcd4a5 8. /build/src/Functions/IFunction.cpp:645: DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x0000000012d96b0c 9. /build/src/Functions/IFunction.cpp:585: DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x0000000012d9665b 10. /build/src/Functions/IFunction.cpp:606: DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x0000000012d96edc 11. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3544: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000014033cc9 12. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3838: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000014019a9e 13. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3980: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000014018e31 14. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:4304: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000014042fa7 15. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5605: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000014013749 16. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000140127f9 17. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000014011fce 18. /build/src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000001406ce8a 19. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000014973b42 20. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000001497268d 21. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000014974d24 22. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001492924b 23. /build/src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88641 24. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 25. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 26. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 27. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 28. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 29. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 30. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 31. ? @ 0x00007fbc6213eac3 2025.07.28 11:51:33.734792 [ 4581 ] {} TCPHandler: Code: 44. DB::Exception: Cannot create column with type 'FixedString(1000000)' 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(map('a', '42'), 'Map(String, FixedString(1000000))'). (ILLEGAL_COLUMN), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, unsigned long const&) @ 0x000000000a3d916b 4. /build/src/Interpreters/parseColumnsListForTableFunction.cpp:92: DB::validateDataType(std::shared_ptr const&, DB::DataTypeValidationSettings const&)::$_0::operator()(DB::IDataType const&) const @ 0x0000000014cce8bf 5. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000013bf3d4b 6. /build/src/Interpreters/parseColumnsListForTableFunction.cpp:173: DB::validateDataType(std::shared_ptr const&, DB::DataTypeValidationSettings const&) @ 0x0000000014ccde2d 7. /build/src/Functions/CastOverloadResolver.cpp:128: DB::CastOverloadResolverImpl::getReturnTypeImpl(std::vector> const&) const @ 0x0000000012dcd4a5 8. /build/src/Functions/IFunction.cpp:645: DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x0000000012d96b0c 9. /build/src/Functions/IFunction.cpp:585: DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x0000000012d9665b 10. /build/src/Functions/IFunction.cpp:606: DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x0000000012d96edc 11. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3544: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000014033cc9 12. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3838: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000014019a9e 13. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3980: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000014018e31 14. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:4304: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000014042fa7 15. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5605: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000014013749 16. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000140127f9 17. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000014011fce 18. /build/src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000001406ce8a 19. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000014973b42 20. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000001497268d 21. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000014974d24 22. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001492924b 23. /build/src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88641 24. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 25. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 26. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 27. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 28. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 29. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 30. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 31. ? @ 0x00007fbc6213eac3 2025.07.28 11:51:33.775465 [ 4581 ] {3f376e2b-3c17-4730-8cb9-6669f344399a} executeQuery: Code: 44. DB::Exception: Cannot create column with type 'FixedString(1000000)' 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(map('a', map('b', ['42'])), 'Map(String, Map(String, Array(FixedString(1000000))))'). (ILLEGAL_COLUMN) (version 25.3.6.10636.altinitytest (altinity build)) (from [::1]:33012) (comment: 02981_nested_bad_types.sql) (query 20, line 25) (in query: select map('a', map('b', ['42']))::Map(String, Map(String, Array(FixedString(1000000))));), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, unsigned long const&) @ 0x000000000a3d916b 4. /build/src/Interpreters/parseColumnsListForTableFunction.cpp:92: DB::validateDataType(std::shared_ptr const&, DB::DataTypeValidationSettings const&)::$_0::operator()(DB::IDataType const&) const @ 0x0000000014cce8bf 5. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000013bd9034 6. /build/src/Interpreters/parseColumnsListForTableFunction.cpp:173: DB::validateDataType(std::shared_ptr const&, DB::DataTypeValidationSettings const&) @ 0x0000000014ccde2d 7. /build/src/Functions/CastOverloadResolver.cpp:128: DB::CastOverloadResolverImpl::getReturnTypeImpl(std::vector> const&) const @ 0x0000000012dcd4a5 8. /build/src/Functions/IFunction.cpp:645: DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x0000000012d96b0c 9. /build/src/Functions/IFunction.cpp:585: DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x0000000012d9665b 10. /build/src/Functions/IFunction.cpp:606: DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x0000000012d96edc 11. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3544: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000014033cc9 12. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3838: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000014019a9e 13. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3980: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000014018e31 14. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:4304: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000014042fa7 15. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5605: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000014013749 16. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000140127f9 17. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000014011fce 18. /build/src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000001406ce8a 19. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000014973b42 20. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000001497268d 21. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000014974d24 22. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001492924b 23. /build/src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88641 24. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 25. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 26. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 27. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 28. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 29. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 30. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 31. ? @ 0x00007fbc6213eac3 2025.07.28 11:51:33.781387 [ 4581 ] {} TCPHandler: Code: 44. DB::Exception: Cannot create column with type 'FixedString(1000000)' 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(map('a', map('b', ['42'])), 'Map(String, Map(String, Array(FixedString(1000000))))'). (ILLEGAL_COLUMN), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, unsigned long const&) @ 0x000000000a3d916b 4. /build/src/Interpreters/parseColumnsListForTableFunction.cpp:92: DB::validateDataType(std::shared_ptr const&, DB::DataTypeValidationSettings const&)::$_0::operator()(DB::IDataType const&) const @ 0x0000000014cce8bf 5. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000013bd9034 6. /build/src/Interpreters/parseColumnsListForTableFunction.cpp:173: DB::validateDataType(std::shared_ptr const&, DB::DataTypeValidationSettings const&) @ 0x0000000014ccde2d 7. /build/src/Functions/CastOverloadResolver.cpp:128: DB::CastOverloadResolverImpl::getReturnTypeImpl(std::vector> const&) const @ 0x0000000012dcd4a5 8. /build/src/Functions/IFunction.cpp:645: DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x0000000012d96b0c 9. /build/src/Functions/IFunction.cpp:585: DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x0000000012d9665b 10. /build/src/Functions/IFunction.cpp:606: DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x0000000012d96edc 11. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3544: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000014033cc9 12. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3838: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000014019a9e 13. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3980: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000014018e31 14. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:4304: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000014042fa7 15. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5605: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000014013749 16. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000140127f9 17. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000014011fce 18. /build/src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000001406ce8a 19. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000014973b42 20. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000001497268d 21. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000014974d24 22. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001492924b 23. /build/src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88641 24. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 25. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 26. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 27. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 28. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 29. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 30. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 31. ? @ 0x00007fbc6213eac3 2025.07.28 11:51:33.909607 [ 4581 ] {33b1945e-29e4-4db7-89b6-ad4436664543} executeQuery: Code: 44. DB::Exception: Cannot create column with type 'FixedString(1000000)' 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(('a', '42'), 'Tuple(String, FixedString(1000000))'). (ILLEGAL_COLUMN) (version 25.3.6.10636.altinitytest (altinity build)) (from [::1]:33012) (comment: 02981_nested_bad_types.sql) (query 21, line 26) (in query: select tuple('a', '42')::Tuple(String, FixedString(1000000));), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, unsigned long const&) @ 0x000000000a3d916b 4. /build/src/Interpreters/parseColumnsListForTableFunction.cpp:92: DB::validateDataType(std::shared_ptr const&, DB::DataTypeValidationSettings const&)::$_0::operator()(DB::IDataType const&) const @ 0x0000000014cce8bf 5. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000013c0b669 6. /build/src/Interpreters/parseColumnsListForTableFunction.cpp:173: DB::validateDataType(std::shared_ptr const&, DB::DataTypeValidationSettings const&) @ 0x0000000014ccde2d 7. /build/src/Functions/CastOverloadResolver.cpp:128: DB::CastOverloadResolverImpl::getReturnTypeImpl(std::vector> const&) const @ 0x0000000012dcd4a5 8. /build/src/Functions/IFunction.cpp:645: DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x0000000012d96b0c 9. /build/src/Functions/IFunction.cpp:585: DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x0000000012d9665b 10. /build/src/Functions/IFunction.cpp:606: DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x0000000012d96edc 11. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3544: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000014033cc9 12. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3838: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000014019a9e 13. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3980: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000014018e31 14. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:4304: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000014042fa7 15. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5605: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000014013749 16. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000140127f9 17. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000014011fce 18. /build/src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000001406ce8a 19. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000014973b42 20. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000001497268d 21. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000014974d24 22. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001492924b 23. /build/src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88641 24. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 25. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 26. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 27. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 28. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 29. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 30. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 31. ? @ 0x00007fbc6213eac3 2025.07.28 11:51:34.008531 [ 4581 ] {} TCPHandler: Code: 44. DB::Exception: Cannot create column with type 'FixedString(1000000)' 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(('a', '42'), 'Tuple(String, FixedString(1000000))'). (ILLEGAL_COLUMN), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, unsigned long const&) @ 0x000000000a3d916b 4. /build/src/Interpreters/parseColumnsListForTableFunction.cpp:92: DB::validateDataType(std::shared_ptr const&, DB::DataTypeValidationSettings const&)::$_0::operator()(DB::IDataType const&) const @ 0x0000000014cce8bf 5. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000013c0b669 6. /build/src/Interpreters/parseColumnsListForTableFunction.cpp:173: DB::validateDataType(std::shared_ptr const&, DB::DataTypeValidationSettings const&) @ 0x0000000014ccde2d 7. /build/src/Functions/CastOverloadResolver.cpp:128: DB::CastOverloadResolverImpl::getReturnTypeImpl(std::vector> const&) const @ 0x0000000012dcd4a5 8. /build/src/Functions/IFunction.cpp:645: DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x0000000012d96b0c 9. /build/src/Functions/IFunction.cpp:585: DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x0000000012d9665b 10. /build/src/Functions/IFunction.cpp:606: DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x0000000012d96edc 11. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3544: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000014033cc9 12. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3838: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000014019a9e 13. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3980: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000014018e31 14. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:4304: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000014042fa7 15. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5605: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000014013749 16. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000140127f9 17. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000014011fce 18. /build/src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000001406ce8a 19. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000014973b42 20. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000001497268d 21. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000014974d24 22. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001492924b 23. /build/src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88641 24. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 25. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 26. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 27. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 28. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 29. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 30. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 31. ? @ 0x00007fbc6213eac3 2025.07.28 11:51:34.113692 [ 4581 ] {4bf5d31a-1e1c-4fb8-8180-6c6e6da539b6} executeQuery: Code: 44. DB::Exception: Cannot create column with type 'FixedString(1000000)' 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(('a', [map('b', '42')]), 'Tuple(String, Array(Map(String, FixedString(1000000))))'). (ILLEGAL_COLUMN) (version 25.3.6.10636.altinitytest (altinity build)) (from [::1]:33012) (comment: 02981_nested_bad_types.sql) (query 22, line 27) (in query: select tuple('a', [map('b', '42')])::Tuple(String, Array(Map(String, FixedString(1000000))));), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, unsigned long const&) @ 0x000000000a3d916b 4. /build/src/Interpreters/parseColumnsListForTableFunction.cpp:92: DB::validateDataType(std::shared_ptr const&, DB::DataTypeValidationSettings const&)::$_0::operator()(DB::IDataType const&) const @ 0x0000000014cce8bf 5. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000013bf3d4b 6. /build/src/DataTypes/DataTypeTuple.cpp:413: DB::DataTypeTuple::forEachChild(std::function const&) const @ 0x0000000013c0b675 7. /build/src/Interpreters/parseColumnsListForTableFunction.cpp:173: DB::validateDataType(std::shared_ptr const&, DB::DataTypeValidationSettings const&) @ 0x0000000014ccde2d 8. /build/src/Functions/CastOverloadResolver.cpp:128: DB::CastOverloadResolverImpl::getReturnTypeImpl(std::vector> const&) const @ 0x0000000012dcd4a5 9. /build/src/Functions/IFunction.cpp:645: DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x0000000012d96b0c 10. /build/src/Functions/IFunction.cpp:585: DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x0000000012d9665b 11. /build/src/Functions/IFunction.cpp:606: DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x0000000012d96edc 12. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3544: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000014033cc9 13. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3838: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000014019a9e 14. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3980: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000014018e31 15. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:4304: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000014042fa7 16. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5605: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000014013749 17. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000140127f9 18. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000014011fce 19. /build/src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000001406ce8a 20. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000014973b42 21. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000001497268d 22. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000014974d24 23. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001492924b 24. /build/src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88641 25. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 26. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 27. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 28. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 29. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 30. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 31. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 2025.07.28 11:51:34.123108 [ 4581 ] {} TCPHandler: Code: 44. DB::Exception: Cannot create column with type 'FixedString(1000000)' 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(('a', [map('b', '42')]), 'Tuple(String, Array(Map(String, FixedString(1000000))))'). (ILLEGAL_COLUMN), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, unsigned long const&) @ 0x000000000a3d916b 4. /build/src/Interpreters/parseColumnsListForTableFunction.cpp:92: DB::validateDataType(std::shared_ptr const&, DB::DataTypeValidationSettings const&)::$_0::operator()(DB::IDataType const&) const @ 0x0000000014cce8bf 5. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000013bf3d4b 6. /build/src/DataTypes/DataTypeTuple.cpp:413: DB::DataTypeTuple::forEachChild(std::function const&) const @ 0x0000000013c0b675 7. /build/src/Interpreters/parseColumnsListForTableFunction.cpp:173: DB::validateDataType(std::shared_ptr const&, DB::DataTypeValidationSettings const&) @ 0x0000000014ccde2d 8. /build/src/Functions/CastOverloadResolver.cpp:128: DB::CastOverloadResolverImpl::getReturnTypeImpl(std::vector> const&) const @ 0x0000000012dcd4a5 9. /build/src/Functions/IFunction.cpp:645: DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x0000000012d96b0c 10. /build/src/Functions/IFunction.cpp:585: DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x0000000012d9665b 11. /build/src/Functions/IFunction.cpp:606: DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x0000000012d96edc 12. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3544: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000014033cc9 13. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3838: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000014019a9e 14. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3980: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000014018e31 15. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:4304: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000014042fa7 16. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5605: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000014013749 17. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000140127f9 18. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000014011fce 19. /build/src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000001406ce8a 20. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000014973b42 21. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000001497268d 22. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000014974d24 23. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001492924b 24. /build/src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88641 25. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 26. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 27. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 28. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 29. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 30. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 31. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 2025.07.28 11:51:34.230366 [ 4581 ] {486960b4-f9a2-4a84-9ac5-25d658d4bcd6} executeQuery: Code: 44. DB::Exception: Cannot create column with type 'FixedString(1000000)' 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.6.10636.altinitytest (altinity build)) (from [::1]:33012) (comment: 02981_nested_bad_types.sql) (query 23, line 29) (in query: create table test (x Array(FixedString(1000000))) engine=Memory;), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, unsigned long const&) @ 0x000000000a3d916b 4. /build/src/Interpreters/parseColumnsListForTableFunction.cpp:92: DB::validateDataType(std::shared_ptr const&, DB::DataTypeValidationSettings const&)::$_0::operator()(DB::IDataType const&) const @ 0x0000000014cce8bf 5. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000013bd9034 6. /build/src/Interpreters/parseColumnsListForTableFunction.cpp:173: DB::validateDataType(std::shared_ptr const&, DB::DataTypeValidationSettings const&) @ 0x0000000014ccde2d 7. /build/src/Interpreters/InterpreterCreateQuery.cpp:1037: DB::InterpreterCreateQuery::validateTableStructure(DB::ASTCreateQuery const&, DB::InterpreterCreateQuery::TableProperties const&) const @ 0x00000000148f3cdc 8. /build/src/Interpreters/InterpreterCreateQuery.cpp:1007: DB::InterpreterCreateQuery::getTablePropertiesAndNormalizeCreateQuery(DB::ASTCreateQuery&, DB::LoadingStrictnessLevel) const @ 0x00000000148f0ec3 9. /build/src/Interpreters/InterpreterCreateQuery.cpp:1657: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000148f901b 10. /build/src/Interpreters/InterpreterCreateQuery.cpp:2352: DB::InterpreterCreateQuery::execute() @ 0x0000000014905a41 11. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88dc9 12. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 13. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 14. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 15. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 16. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 17. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 18. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 19. ? @ 0x00007fbc6213eac3 20. ? @ 0x00007fbc621d0850 2025.07.28 11:51:34.236945 [ 15481 ] {4fc48904-d0b8-4f19-ad13-0c37d1566448} executeQuery: Code: 439. DB::Exception: Cannot schedule a task: failed to start the thread (threads=0, jobs=0). (CANNOT_SCHEDULE_TASK) (version 25.3.6.10636.altinitytest (altinity build)) (from 0.0.0.0:0) (comment: 00506_union_distributed.sql) (in query: /* ddl_entry=query-0000000041 */ CREATE TABLE test_5.union2 UUID '70f823c5-01d7-4f31-8a69-43cecc6e81f2' (`date` Date, `a` Int32, `b` Int32, `c` Int32, `d` Int32) ENGINE = Distributed(test_shard_localhost, currentDatabase(), 'union1')), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000fccaeeb 4. /build/src/Common/ThreadPool.cpp:275: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000fccc813 5. /build/src/Common/ThreadPool.cpp:308: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fcc8286 6. /build/src/Common/ThreadPool.cpp:494: ThreadPoolImpl>::scheduleOrThrowOnError(std::function, Priority) @ 0x000000000fcc7a0e 7. /build/src/Common/threadPoolCallbackRunner.h:188: DB::ThreadPoolCallbackRunnerLocal>, std::function>::operator()(std::function&&, Priority, std::optional) @ 0x00000000119df78e 8. /build/src/Storages/StorageDistributed.cpp:1298: DB::StorageDistributed::initializeFromDisk() @ 0x0000000015d5e99a 9. /build/src/Storages/StorageDistributed.cpp:433: 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) @ 0x0000000015d5d52e 10. /build/contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: std::shared_ptr std::allocate_shared[abi:se190107], DB::StorageID const&, DB::ColumnsDescription const&, DB::ConstraintsDescription const&, String const&, String&, String&, String&, std::shared_ptr const&, std::shared_ptr const&, String&, String const&, DB::DistributedSettings&, DB::LoadingStrictnessLevel const&, 0>(std::allocator const&, DB::StorageID const&, DB::ColumnsDescription const&, DB::ConstraintsDescription const&, String const&, String&, String&, String&, std::shared_ptr const&, std::shared_ptr const&, String&, String const&, DB::DistributedSettings&, DB::LoadingStrictnessLevel const&) @ 0x0000000015d7a34b 11. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:851: std::shared_ptr std::__function::__policy_invoker (DB::StorageFactory::Arguments const&)>::__call_impl[abi:se190107] (DB::StorageFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::StorageFactory::Arguments const&) @ 0x0000000015d75069 12. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000015d81ea2 13. /build/src/Interpreters/InterpreterCreateQuery.cpp:1945: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x00000000149009bb 14. /build/src/Interpreters/InterpreterCreateQuery.cpp:1743: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000148f9aa9 15. /build/src/Interpreters/InterpreterCreateQuery.cpp:2352: DB::InterpreterCreateQuery::execute() @ 0x0000000014905a41 16. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88dc9 17. /build/src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x0000000014c8ca7b 18. /build/src/Interpreters/DDLWorker.cpp:510: DB::DDLWorker::tryExecuteQuery(DB::DDLTaskBase&, std::shared_ptr const&, bool) @ 0x00000000144dab9e 19. /build/src/Interpreters/DDLWorker.cpp:675: DB::DDLWorker::processTask(DB::DDLTaskBase&, std::shared_ptr const&, bool) @ 0x00000000144d8ffe 20. /build/src/Databases/DatabaseReplicatedWorker.cpp:372: DB::DatabaseReplicatedDDLWorker::tryEnqueueAndExecuteEntry(DB::DDLLogEntry&, std::shared_ptr, bool) @ 0x0000000013dc29ab 21. /build/src/Databases/DatabaseReplicated.cpp:1139: DB::DatabaseReplicated::tryEnqueueReplicatedDDL(std::shared_ptr const&, std::shared_ptr, DB::QueryFlags) @ 0x0000000013d9f73c 22. /build/src/Interpreters/InterpreterCreateQuery.cpp:1723: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000148f96f8 23. /build/src/Interpreters/InterpreterCreateQuery.cpp:2352: DB::InterpreterCreateQuery::execute() @ 0x0000000014905a41 24. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88dc9 25. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 26. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 27. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 28. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 29. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 30. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 31. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 2025.07.28 11:51:34.237486 [ 4581 ] {} TCPHandler: Code: 44. DB::Exception: Cannot create column with type 'FixedString(1000000)' 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. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, unsigned long const&) @ 0x000000000a3d916b 4. /build/src/Interpreters/parseColumnsListForTableFunction.cpp:92: DB::validateDataType(std::shared_ptr const&, DB::DataTypeValidationSettings const&)::$_0::operator()(DB::IDataType const&) const @ 0x0000000014cce8bf 5. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000013bd9034 6. /build/src/Interpreters/parseColumnsListForTableFunction.cpp:173: DB::validateDataType(std::shared_ptr const&, DB::DataTypeValidationSettings const&) @ 0x0000000014ccde2d 7. /build/src/Interpreters/InterpreterCreateQuery.cpp:1037: DB::InterpreterCreateQuery::validateTableStructure(DB::ASTCreateQuery const&, DB::InterpreterCreateQuery::TableProperties const&) const @ 0x00000000148f3cdc 8. /build/src/Interpreters/InterpreterCreateQuery.cpp:1007: DB::InterpreterCreateQuery::getTablePropertiesAndNormalizeCreateQuery(DB::ASTCreateQuery&, DB::LoadingStrictnessLevel) const @ 0x00000000148f0ec3 9. /build/src/Interpreters/InterpreterCreateQuery.cpp:1657: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000148f901b 10. /build/src/Interpreters/InterpreterCreateQuery.cpp:2352: DB::InterpreterCreateQuery::execute() @ 0x0000000014905a41 11. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88dc9 12. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 13. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 14. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 15. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 16. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 17. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 18. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 19. ? @ 0x00007fbc6213eac3 20. ? @ 0x00007fbc621d0850 2025.07.28 11:51:34.271018 [ 4581 ] {e00f2043-fcbb-4cf1-85ca-fd6f8d259878} executeQuery: Code: 44. DB::Exception: Cannot create column with type 'FixedString(1000000)' 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.6.10636.altinitytest (altinity build)) (from [::1]:33012) (comment: 02981_nested_bad_types.sql) (query 24, line 30) (in query: create table test (x Array(Array(FixedString(1000000)))) engine=Memory;), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, unsigned long const&) @ 0x000000000a3d916b 4. /build/src/Interpreters/parseColumnsListForTableFunction.cpp:92: DB::validateDataType(std::shared_ptr const&, DB::DataTypeValidationSettings const&)::$_0::operator()(DB::IDataType const&) const @ 0x0000000014cce8bf 5. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000013bd9034 6. /build/src/Interpreters/parseColumnsListForTableFunction.cpp:173: DB::validateDataType(std::shared_ptr const&, DB::DataTypeValidationSettings const&) @ 0x0000000014ccde2d 7. /build/src/Interpreters/InterpreterCreateQuery.cpp:1037: DB::InterpreterCreateQuery::validateTableStructure(DB::ASTCreateQuery const&, DB::InterpreterCreateQuery::TableProperties const&) const @ 0x00000000148f3cdc 8. /build/src/Interpreters/InterpreterCreateQuery.cpp:1007: DB::InterpreterCreateQuery::getTablePropertiesAndNormalizeCreateQuery(DB::ASTCreateQuery&, DB::LoadingStrictnessLevel) const @ 0x00000000148f0ec3 9. /build/src/Interpreters/InterpreterCreateQuery.cpp:1657: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000148f901b 10. /build/src/Interpreters/InterpreterCreateQuery.cpp:2352: DB::InterpreterCreateQuery::execute() @ 0x0000000014905a41 11. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88dc9 12. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 13. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 14. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 15. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 16. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 17. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 18. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 19. ? @ 0x00007fbc6213eac3 20. ? @ 0x00007fbc621d0850 2025.07.28 11:51:34.271805 [ 15481 ] {4fc48904-d0b8-4f19-ad13-0c37d1566448} executeQuery: Code: 439. DB::Exception: Cannot schedule a task: failed to start the thread (threads=0, jobs=0). (CANNOT_SCHEDULE_TASK) (version 25.3.6.10636.altinitytest (altinity build)) (from [::1]:33034) (comment: 00506_union_distributed.sql) (query 7, line 13) (in query: CREATE TABLE union2 ( date Date, a Int32, b Int32, c Int32, d Int32) ENGINE = Distributed(test_shard_localhost, currentDatabase(), 'union1');), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000fccaeeb 4. /build/src/Common/ThreadPool.cpp:275: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000fccc813 5. /build/src/Common/ThreadPool.cpp:308: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fcc8286 6. /build/src/Common/ThreadPool.cpp:494: ThreadPoolImpl>::scheduleOrThrowOnError(std::function, Priority) @ 0x000000000fcc7a0e 7. /build/src/Common/threadPoolCallbackRunner.h:188: DB::ThreadPoolCallbackRunnerLocal>, std::function>::operator()(std::function&&, Priority, std::optional) @ 0x00000000119df78e 8. /build/src/Storages/StorageDistributed.cpp:1298: DB::StorageDistributed::initializeFromDisk() @ 0x0000000015d5e99a 9. /build/src/Storages/StorageDistributed.cpp:433: 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) @ 0x0000000015d5d52e 10. /build/contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: std::shared_ptr std::allocate_shared[abi:se190107], DB::StorageID const&, DB::ColumnsDescription const&, DB::ConstraintsDescription const&, String const&, String&, String&, String&, std::shared_ptr const&, std::shared_ptr const&, String&, String const&, DB::DistributedSettings&, DB::LoadingStrictnessLevel const&, 0>(std::allocator const&, DB::StorageID const&, DB::ColumnsDescription const&, DB::ConstraintsDescription const&, String const&, String&, String&, String&, std::shared_ptr const&, std::shared_ptr const&, String&, String const&, DB::DistributedSettings&, DB::LoadingStrictnessLevel const&) @ 0x0000000015d7a34b 11. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:851: std::shared_ptr std::__function::__policy_invoker (DB::StorageFactory::Arguments const&)>::__call_impl[abi:se190107] (DB::StorageFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::StorageFactory::Arguments const&) @ 0x0000000015d75069 12. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000015d81ea2 13. /build/src/Interpreters/InterpreterCreateQuery.cpp:1945: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x00000000149009bb 14. /build/src/Interpreters/InterpreterCreateQuery.cpp:1743: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000148f9aa9 15. /build/src/Interpreters/InterpreterCreateQuery.cpp:2352: DB::InterpreterCreateQuery::execute() @ 0x0000000014905a41 16. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88dc9 17. /build/src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x0000000014c8ca7b 18. /build/src/Interpreters/DDLWorker.cpp:510: DB::DDLWorker::tryExecuteQuery(DB::DDLTaskBase&, std::shared_ptr const&, bool) @ 0x00000000144dab9e 19. /build/src/Interpreters/DDLWorker.cpp:675: DB::DDLWorker::processTask(DB::DDLTaskBase&, std::shared_ptr const&, bool) @ 0x00000000144d8ffe 20. /build/src/Databases/DatabaseReplicatedWorker.cpp:372: DB::DatabaseReplicatedDDLWorker::tryEnqueueAndExecuteEntry(DB::DDLLogEntry&, std::shared_ptr, bool) @ 0x0000000013dc29ab 21. /build/src/Databases/DatabaseReplicated.cpp:1139: DB::DatabaseReplicated::tryEnqueueReplicatedDDL(std::shared_ptr const&, std::shared_ptr, DB::QueryFlags) @ 0x0000000013d9f73c 22. /build/src/Interpreters/InterpreterCreateQuery.cpp:1723: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000148f96f8 23. /build/src/Interpreters/InterpreterCreateQuery.cpp:2352: DB::InterpreterCreateQuery::execute() @ 0x0000000014905a41 24. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88dc9 25. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 26. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 27. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 28. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 29. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 30. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 31. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 2025.07.28 11:51:34.359279 [ 4581 ] {} TCPHandler: Code: 44. DB::Exception: Cannot create column with type 'FixedString(1000000)' 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. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, unsigned long const&) @ 0x000000000a3d916b 4. /build/src/Interpreters/parseColumnsListForTableFunction.cpp:92: DB::validateDataType(std::shared_ptr const&, DB::DataTypeValidationSettings const&)::$_0::operator()(DB::IDataType const&) const @ 0x0000000014cce8bf 5. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000013bd9034 6. /build/src/Interpreters/parseColumnsListForTableFunction.cpp:173: DB::validateDataType(std::shared_ptr const&, DB::DataTypeValidationSettings const&) @ 0x0000000014ccde2d 7. /build/src/Interpreters/InterpreterCreateQuery.cpp:1037: DB::InterpreterCreateQuery::validateTableStructure(DB::ASTCreateQuery const&, DB::InterpreterCreateQuery::TableProperties const&) const @ 0x00000000148f3cdc 8. /build/src/Interpreters/InterpreterCreateQuery.cpp:1007: DB::InterpreterCreateQuery::getTablePropertiesAndNormalizeCreateQuery(DB::ASTCreateQuery&, DB::LoadingStrictnessLevel) const @ 0x00000000148f0ec3 9. /build/src/Interpreters/InterpreterCreateQuery.cpp:1657: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000148f901b 10. /build/src/Interpreters/InterpreterCreateQuery.cpp:2352: DB::InterpreterCreateQuery::execute() @ 0x0000000014905a41 11. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88dc9 12. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 13. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 14. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 15. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 16. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 17. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 18. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 19. ? @ 0x00007fbc6213eac3 20. ? @ 0x00007fbc621d0850 2025.07.28 11:51:34.372837 [ 15481 ] {} 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. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000fccaeeb 4. /build/src/Common/ThreadPool.cpp:275: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000fccc813 5. /build/src/Common/ThreadPool.cpp:308: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fcc8286 6. /build/src/Common/ThreadPool.cpp:494: ThreadPoolImpl>::scheduleOrThrowOnError(std::function, Priority) @ 0x000000000fcc7a0e 7. /build/src/Common/threadPoolCallbackRunner.h:188: DB::ThreadPoolCallbackRunnerLocal>, std::function>::operator()(std::function&&, Priority, std::optional) @ 0x00000000119df78e 8. /build/src/Storages/StorageDistributed.cpp:1298: DB::StorageDistributed::initializeFromDisk() @ 0x0000000015d5e99a 9. /build/src/Storages/StorageDistributed.cpp:433: 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) @ 0x0000000015d5d52e 10. /build/contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: std::shared_ptr std::allocate_shared[abi:se190107], DB::StorageID const&, DB::ColumnsDescription const&, DB::ConstraintsDescription const&, String const&, String&, String&, String&, std::shared_ptr const&, std::shared_ptr const&, String&, String const&, DB::DistributedSettings&, DB::LoadingStrictnessLevel const&, 0>(std::allocator const&, DB::StorageID const&, DB::ColumnsDescription const&, DB::ConstraintsDescription const&, String const&, String&, String&, String&, std::shared_ptr const&, std::shared_ptr const&, String&, String const&, DB::DistributedSettings&, DB::LoadingStrictnessLevel const&) @ 0x0000000015d7a34b 11. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:851: std::shared_ptr std::__function::__policy_invoker (DB::StorageFactory::Arguments const&)>::__call_impl[abi:se190107] (DB::StorageFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::StorageFactory::Arguments const&) @ 0x0000000015d75069 12. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000015d81ea2 13. /build/src/Interpreters/InterpreterCreateQuery.cpp:1945: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x00000000149009bb 14. /build/src/Interpreters/InterpreterCreateQuery.cpp:1743: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000148f9aa9 15. /build/src/Interpreters/InterpreterCreateQuery.cpp:2352: DB::InterpreterCreateQuery::execute() @ 0x0000000014905a41 16. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88dc9 17. /build/src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x0000000014c8ca7b 18. /build/src/Interpreters/DDLWorker.cpp:510: DB::DDLWorker::tryExecuteQuery(DB::DDLTaskBase&, std::shared_ptr const&, bool) @ 0x00000000144dab9e 19. /build/src/Interpreters/DDLWorker.cpp:675: DB::DDLWorker::processTask(DB::DDLTaskBase&, std::shared_ptr const&, bool) @ 0x00000000144d8ffe 20. /build/src/Databases/DatabaseReplicatedWorker.cpp:372: DB::DatabaseReplicatedDDLWorker::tryEnqueueAndExecuteEntry(DB::DDLLogEntry&, std::shared_ptr, bool) @ 0x0000000013dc29ab 21. /build/src/Databases/DatabaseReplicated.cpp:1139: DB::DatabaseReplicated::tryEnqueueReplicatedDDL(std::shared_ptr const&, std::shared_ptr, DB::QueryFlags) @ 0x0000000013d9f73c 22. /build/src/Interpreters/InterpreterCreateQuery.cpp:1723: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000148f96f8 23. /build/src/Interpreters/InterpreterCreateQuery.cpp:2352: DB::InterpreterCreateQuery::execute() @ 0x0000000014905a41 24. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88dc9 25. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 26. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 27. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 28. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 29. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 30. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 31. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 2025.07.28 11:51:34.440494 [ 4581 ] {8e64134d-d7cc-4638-9207-91a86c9af3f7} executeQuery: Code: 44. DB::Exception: Cannot create column with type 'FixedString(1000000)' 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.6.10636.altinitytest (altinity build)) (from [::1]:33012) (comment: 02981_nested_bad_types.sql) (query 25, line 31) (in query: create table test (x Map(String, FixedString(1000000))) engine=Memory;), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, unsigned long const&) @ 0x000000000a3d916b 4. /build/src/Interpreters/parseColumnsListForTableFunction.cpp:92: DB::validateDataType(std::shared_ptr const&, DB::DataTypeValidationSettings const&)::$_0::operator()(DB::IDataType const&) const @ 0x0000000014cce8bf 5. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000013bf3d4b 6. /build/src/Interpreters/parseColumnsListForTableFunction.cpp:173: DB::validateDataType(std::shared_ptr const&, DB::DataTypeValidationSettings const&) @ 0x0000000014ccde2d 7. /build/src/Interpreters/InterpreterCreateQuery.cpp:1037: DB::InterpreterCreateQuery::validateTableStructure(DB::ASTCreateQuery const&, DB::InterpreterCreateQuery::TableProperties const&) const @ 0x00000000148f3cdc 8. /build/src/Interpreters/InterpreterCreateQuery.cpp:1007: DB::InterpreterCreateQuery::getTablePropertiesAndNormalizeCreateQuery(DB::ASTCreateQuery&, DB::LoadingStrictnessLevel) const @ 0x00000000148f0ec3 9. /build/src/Interpreters/InterpreterCreateQuery.cpp:1657: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000148f901b 10. /build/src/Interpreters/InterpreterCreateQuery.cpp:2352: DB::InterpreterCreateQuery::execute() @ 0x0000000014905a41 11. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88dc9 12. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 13. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 14. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 15. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 16. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 17. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 18. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 19. ? @ 0x00007fbc6213eac3 20. ? @ 0x00007fbc621d0850 2025.07.28 11:51:34.453961 [ 4581 ] {} TCPHandler: Code: 44. DB::Exception: Cannot create column with type 'FixedString(1000000)' 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. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, unsigned long const&) @ 0x000000000a3d916b 4. /build/src/Interpreters/parseColumnsListForTableFunction.cpp:92: DB::validateDataType(std::shared_ptr const&, DB::DataTypeValidationSettings const&)::$_0::operator()(DB::IDataType const&) const @ 0x0000000014cce8bf 5. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000013bf3d4b 6. /build/src/Interpreters/parseColumnsListForTableFunction.cpp:173: DB::validateDataType(std::shared_ptr const&, DB::DataTypeValidationSettings const&) @ 0x0000000014ccde2d 7. /build/src/Interpreters/InterpreterCreateQuery.cpp:1037: DB::InterpreterCreateQuery::validateTableStructure(DB::ASTCreateQuery const&, DB::InterpreterCreateQuery::TableProperties const&) const @ 0x00000000148f3cdc 8. /build/src/Interpreters/InterpreterCreateQuery.cpp:1007: DB::InterpreterCreateQuery::getTablePropertiesAndNormalizeCreateQuery(DB::ASTCreateQuery&, DB::LoadingStrictnessLevel) const @ 0x00000000148f0ec3 9. /build/src/Interpreters/InterpreterCreateQuery.cpp:1657: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000148f901b 10. /build/src/Interpreters/InterpreterCreateQuery.cpp:2352: DB::InterpreterCreateQuery::execute() @ 0x0000000014905a41 11. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88dc9 12. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 13. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 14. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 15. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 16. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 17. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 18. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 19. ? @ 0x00007fbc6213eac3 20. ? @ 0x00007fbc621d0850 2025.07.28 11:51:34.528436 [ 4581 ] {5ab363e8-b1ab-410b-a5cd-3bb51e8fff8b} executeQuery: Code: 44. DB::Exception: Cannot create column with type 'FixedString(1000000)' 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.6.10636.altinitytest (altinity build)) (from [::1]:33012) (comment: 02981_nested_bad_types.sql) (query 26, line 32) (in query: create table test (x Map(String, Map(String, FixedString(1000000)))) engine=Memory;), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, unsigned long const&) @ 0x000000000a3d916b 4. /build/src/Interpreters/parseColumnsListForTableFunction.cpp:92: DB::validateDataType(std::shared_ptr const&, DB::DataTypeValidationSettings const&)::$_0::operator()(DB::IDataType const&) const @ 0x0000000014cce8bf 5. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000013bf3d4b 6. /build/src/Interpreters/parseColumnsListForTableFunction.cpp:173: DB::validateDataType(std::shared_ptr const&, DB::DataTypeValidationSettings const&) @ 0x0000000014ccde2d 7. /build/src/Interpreters/InterpreterCreateQuery.cpp:1037: DB::InterpreterCreateQuery::validateTableStructure(DB::ASTCreateQuery const&, DB::InterpreterCreateQuery::TableProperties const&) const @ 0x00000000148f3cdc 8. /build/src/Interpreters/InterpreterCreateQuery.cpp:1007: DB::InterpreterCreateQuery::getTablePropertiesAndNormalizeCreateQuery(DB::ASTCreateQuery&, DB::LoadingStrictnessLevel) const @ 0x00000000148f0ec3 9. /build/src/Interpreters/InterpreterCreateQuery.cpp:1657: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000148f901b 10. /build/src/Interpreters/InterpreterCreateQuery.cpp:2352: DB::InterpreterCreateQuery::execute() @ 0x0000000014905a41 11. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88dc9 12. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 13. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 14. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 15. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 16. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 17. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 18. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 19. ? @ 0x00007fbc6213eac3 20. ? @ 0x00007fbc621d0850 2025.07.28 11:51:34.533183 [ 4581 ] {} TCPHandler: Code: 44. DB::Exception: Cannot create column with type 'FixedString(1000000)' 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. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, unsigned long const&) @ 0x000000000a3d916b 4. /build/src/Interpreters/parseColumnsListForTableFunction.cpp:92: DB::validateDataType(std::shared_ptr const&, DB::DataTypeValidationSettings const&)::$_0::operator()(DB::IDataType const&) const @ 0x0000000014cce8bf 5. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000013bf3d4b 6. /build/src/Interpreters/parseColumnsListForTableFunction.cpp:173: DB::validateDataType(std::shared_ptr const&, DB::DataTypeValidationSettings const&) @ 0x0000000014ccde2d 7. /build/src/Interpreters/InterpreterCreateQuery.cpp:1037: DB::InterpreterCreateQuery::validateTableStructure(DB::ASTCreateQuery const&, DB::InterpreterCreateQuery::TableProperties const&) const @ 0x00000000148f3cdc 8. /build/src/Interpreters/InterpreterCreateQuery.cpp:1007: DB::InterpreterCreateQuery::getTablePropertiesAndNormalizeCreateQuery(DB::ASTCreateQuery&, DB::LoadingStrictnessLevel) const @ 0x00000000148f0ec3 9. /build/src/Interpreters/InterpreterCreateQuery.cpp:1657: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000148f901b 10. /build/src/Interpreters/InterpreterCreateQuery.cpp:2352: DB::InterpreterCreateQuery::execute() @ 0x0000000014905a41 11. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88dc9 12. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 13. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 14. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 15. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 16. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 17. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 18. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 19. ? @ 0x00007fbc6213eac3 20. ? @ 0x00007fbc621d0850 2025.07.28 11:51:34.693499 [ 4581 ] {09178e10-8ada-4798-bb85-aa4bd10bf63d} executeQuery: Code: 44. DB::Exception: Cannot create column with type 'FixedString(1000000)' 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.6.10636.altinitytest (altinity build)) (from [::1]:33012) (comment: 02981_nested_bad_types.sql) (query 27, line 33) (in query: create table test (x Tuple(String, FixedString(1000000))) engine=Memory;), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, unsigned long const&) @ 0x000000000a3d916b 4. /build/src/Interpreters/parseColumnsListForTableFunction.cpp:92: DB::validateDataType(std::shared_ptr const&, DB::DataTypeValidationSettings const&)::$_0::operator()(DB::IDataType const&) const @ 0x0000000014cce8bf 5. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000013c0b669 6. /build/src/Interpreters/parseColumnsListForTableFunction.cpp:173: DB::validateDataType(std::shared_ptr const&, DB::DataTypeValidationSettings const&) @ 0x0000000014ccde2d 7. /build/src/Interpreters/InterpreterCreateQuery.cpp:1037: DB::InterpreterCreateQuery::validateTableStructure(DB::ASTCreateQuery const&, DB::InterpreterCreateQuery::TableProperties const&) const @ 0x00000000148f3cdc 8. /build/src/Interpreters/InterpreterCreateQuery.cpp:1007: DB::InterpreterCreateQuery::getTablePropertiesAndNormalizeCreateQuery(DB::ASTCreateQuery&, DB::LoadingStrictnessLevel) const @ 0x00000000148f0ec3 9. /build/src/Interpreters/InterpreterCreateQuery.cpp:1657: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000148f901b 10. /build/src/Interpreters/InterpreterCreateQuery.cpp:2352: DB::InterpreterCreateQuery::execute() @ 0x0000000014905a41 11. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88dc9 12. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 13. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 14. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 15. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 16. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 17. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 18. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 19. ? @ 0x00007fbc6213eac3 20. ? @ 0x00007fbc621d0850 2025.07.28 11:51:34.700162 [ 4581 ] {} TCPHandler: Code: 44. DB::Exception: Cannot create column with type 'FixedString(1000000)' 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. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, unsigned long const&) @ 0x000000000a3d916b 4. /build/src/Interpreters/parseColumnsListForTableFunction.cpp:92: DB::validateDataType(std::shared_ptr const&, DB::DataTypeValidationSettings const&)::$_0::operator()(DB::IDataType const&) const @ 0x0000000014cce8bf 5. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000013c0b669 6. /build/src/Interpreters/parseColumnsListForTableFunction.cpp:173: DB::validateDataType(std::shared_ptr const&, DB::DataTypeValidationSettings const&) @ 0x0000000014ccde2d 7. /build/src/Interpreters/InterpreterCreateQuery.cpp:1037: DB::InterpreterCreateQuery::validateTableStructure(DB::ASTCreateQuery const&, DB::InterpreterCreateQuery::TableProperties const&) const @ 0x00000000148f3cdc 8. /build/src/Interpreters/InterpreterCreateQuery.cpp:1007: DB::InterpreterCreateQuery::getTablePropertiesAndNormalizeCreateQuery(DB::ASTCreateQuery&, DB::LoadingStrictnessLevel) const @ 0x00000000148f0ec3 9. /build/src/Interpreters/InterpreterCreateQuery.cpp:1657: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000148f901b 10. /build/src/Interpreters/InterpreterCreateQuery.cpp:2352: DB::InterpreterCreateQuery::execute() @ 0x0000000014905a41 11. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88dc9 12. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 13. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 14. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 15. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 16. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 17. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 18. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 19. ? @ 0x00007fbc6213eac3 20. ? @ 0x00007fbc621d0850 2025.07.28 11:51:34.854484 [ 4581 ] {dd79bd74-c3dc-4b0b-aa0c-2293795503b8} executeQuery: Code: 44. DB::Exception: Cannot create column with type 'FixedString(1000000)' 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.6.10636.altinitytest (altinity build)) (from [::1]:33012) (comment: 02981_nested_bad_types.sql) (query 28, line 34) (in query: create table test (x Tuple(String, Array(Map(String, FixedString(1000000))))) engine=Memory;), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, unsigned long const&) @ 0x000000000a3d916b 4. /build/src/Interpreters/parseColumnsListForTableFunction.cpp:92: DB::validateDataType(std::shared_ptr const&, DB::DataTypeValidationSettings const&)::$_0::operator()(DB::IDataType const&) const @ 0x0000000014cce8bf 5. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000013bf3d4b 6. /build/src/DataTypes/DataTypeTuple.cpp:413: DB::DataTypeTuple::forEachChild(std::function const&) const @ 0x0000000013c0b675 7. /build/src/Interpreters/parseColumnsListForTableFunction.cpp:173: DB::validateDataType(std::shared_ptr const&, DB::DataTypeValidationSettings const&) @ 0x0000000014ccde2d 8. /build/src/Interpreters/InterpreterCreateQuery.cpp:1037: DB::InterpreterCreateQuery::validateTableStructure(DB::ASTCreateQuery const&, DB::InterpreterCreateQuery::TableProperties const&) const @ 0x00000000148f3cdc 9. /build/src/Interpreters/InterpreterCreateQuery.cpp:1007: DB::InterpreterCreateQuery::getTablePropertiesAndNormalizeCreateQuery(DB::ASTCreateQuery&, DB::LoadingStrictnessLevel) const @ 0x00000000148f0ec3 10. /build/src/Interpreters/InterpreterCreateQuery.cpp:1657: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000148f901b 11. /build/src/Interpreters/InterpreterCreateQuery.cpp:2352: DB::InterpreterCreateQuery::execute() @ 0x0000000014905a41 12. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88dc9 13. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 14. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 15. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 16. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 17. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 18. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 19. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 20. ? @ 0x00007fbc6213eac3 21. ? @ 0x00007fbc621d0850 2025.07.28 11:51:34.863184 [ 4581 ] {} TCPHandler: Code: 44. DB::Exception: Cannot create column with type 'FixedString(1000000)' 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. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, unsigned long const&) @ 0x000000000a3d916b 4. /build/src/Interpreters/parseColumnsListForTableFunction.cpp:92: DB::validateDataType(std::shared_ptr const&, DB::DataTypeValidationSettings const&)::$_0::operator()(DB::IDataType const&) const @ 0x0000000014cce8bf 5. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000013bf3d4b 6. /build/src/DataTypes/DataTypeTuple.cpp:413: DB::DataTypeTuple::forEachChild(std::function const&) const @ 0x0000000013c0b675 7. /build/src/Interpreters/parseColumnsListForTableFunction.cpp:173: DB::validateDataType(std::shared_ptr const&, DB::DataTypeValidationSettings const&) @ 0x0000000014ccde2d 8. /build/src/Interpreters/InterpreterCreateQuery.cpp:1037: DB::InterpreterCreateQuery::validateTableStructure(DB::ASTCreateQuery const&, DB::InterpreterCreateQuery::TableProperties const&) const @ 0x00000000148f3cdc 9. /build/src/Interpreters/InterpreterCreateQuery.cpp:1007: DB::InterpreterCreateQuery::getTablePropertiesAndNormalizeCreateQuery(DB::ASTCreateQuery&, DB::LoadingStrictnessLevel) const @ 0x00000000148f0ec3 10. /build/src/Interpreters/InterpreterCreateQuery.cpp:1657: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000148f901b 11. /build/src/Interpreters/InterpreterCreateQuery.cpp:2352: DB::InterpreterCreateQuery::execute() @ 0x0000000014905a41 12. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88dc9 13. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 14. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 15. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 16. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 17. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 18. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 19. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 20. ? @ 0x00007fbc6213eac3 21. ? @ 0x00007fbc621d0850 2025.07.28 11:51:35.010893 [ 4581 ] {3a811797-156b-4cf6-95df-c1fc051952dc} executeQuery: Code: 44. DB::Exception: Cannot create column with type 'Variant(String, UInt64)' because Variant type is not allowed. Set setting enable_variant_type = 1 in order to allow it: In scope SELECT CAST('[42]', 'Array(Variant(String, UInt64))'). (ILLEGAL_COLUMN) (version 25.3.6.10636.altinitytest (altinity build)) (from [::1]:33012) (comment: 02981_nested_bad_types.sql) (query 29, line 36) (in query: select [42]::Array(Variant(String, UInt64));), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x000000000a06b56b 4. /build/src/Interpreters/parseColumnsListForTableFunction.cpp:105: DB::validateDataType(std::shared_ptr const&, DB::DataTypeValidationSettings const&)::$_0::operator()(DB::IDataType const&) const @ 0x0000000014cce784 5. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000013bd9034 6. /build/src/Interpreters/parseColumnsListForTableFunction.cpp:173: DB::validateDataType(std::shared_ptr const&, DB::DataTypeValidationSettings const&) @ 0x0000000014ccde2d 7. /build/src/Functions/CastOverloadResolver.cpp:128: DB::CastOverloadResolverImpl::getReturnTypeImpl(std::vector> const&) const @ 0x0000000012dcd4a5 8. /build/src/Functions/IFunction.cpp:645: DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x0000000012d96b0c 9. /build/src/Functions/IFunction.cpp:585: DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x0000000012d9665b 10. /build/src/Functions/IFunction.cpp:606: DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x0000000012d96edc 11. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3544: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000014033cc9 12. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3838: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000014019a9e 13. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3980: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000014018e31 14. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:4304: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000014042fa7 15. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5605: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000014013749 16. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000140127f9 17. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000014011fce 18. /build/src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000001406ce8a 19. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000014973b42 20. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000001497268d 21. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000014974d24 22. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001492924b 23. /build/src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88641 24. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 25. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 26. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 27. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 28. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 29. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 30. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 31. ? @ 0x00007fbc6213eac3 2025.07.28 11:51:35.014778 [ 4581 ] {} TCPHandler: Code: 44. DB::Exception: Cannot create column with type 'Variant(String, UInt64)' because Variant type is not allowed. Set setting enable_variant_type = 1 in order to allow it: In scope SELECT CAST('[42]', 'Array(Variant(String, UInt64))'). (ILLEGAL_COLUMN), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x000000000a06b56b 4. /build/src/Interpreters/parseColumnsListForTableFunction.cpp:105: DB::validateDataType(std::shared_ptr const&, DB::DataTypeValidationSettings const&)::$_0::operator()(DB::IDataType const&) const @ 0x0000000014cce784 5. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000013bd9034 6. /build/src/Interpreters/parseColumnsListForTableFunction.cpp:173: DB::validateDataType(std::shared_ptr const&, DB::DataTypeValidationSettings const&) @ 0x0000000014ccde2d 7. /build/src/Functions/CastOverloadResolver.cpp:128: DB::CastOverloadResolverImpl::getReturnTypeImpl(std::vector> const&) const @ 0x0000000012dcd4a5 8. /build/src/Functions/IFunction.cpp:645: DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x0000000012d96b0c 9. /build/src/Functions/IFunction.cpp:585: DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x0000000012d9665b 10. /build/src/Functions/IFunction.cpp:606: DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x0000000012d96edc 11. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3544: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000014033cc9 12. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3838: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000014019a9e 13. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3980: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000014018e31 14. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:4304: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000014042fa7 15. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5605: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000014013749 16. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000140127f9 17. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000014011fce 18. /build/src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000001406ce8a 19. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000014973b42 20. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000001497268d 21. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000014974d24 22. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001492924b 23. /build/src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88641 24. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 25. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 26. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 27. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 28. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 29. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 30. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 31. ? @ 0x00007fbc6213eac3 2025.07.28 11:51:35.047052 [ 4581 ] {9d639d3b-4813-47eb-bc5b-1c96e0731b62} executeQuery: Code: 44. DB::Exception: Cannot create column with type 'Variant(String, UInt64)' because Variant type is not allowed. Set setting enable_variant_type = 1 in order to allow it: In scope SELECT CAST('[[[42]]]', 'Array(Array(Array(Variant(String, UInt64))))'). (ILLEGAL_COLUMN) (version 25.3.6.10636.altinitytest (altinity build)) (from [::1]:33012) (comment: 02981_nested_bad_types.sql) (query 30, line 37) (in query: select [[[42]]]::Array(Array(Array(Variant(String, UInt64))));), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x000000000a06b56b 4. /build/src/Interpreters/parseColumnsListForTableFunction.cpp:105: DB::validateDataType(std::shared_ptr const&, DB::DataTypeValidationSettings const&)::$_0::operator()(DB::IDataType const&) const @ 0x0000000014cce784 5. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000013bd9034 6. /build/src/Interpreters/parseColumnsListForTableFunction.cpp:173: DB::validateDataType(std::shared_ptr const&, DB::DataTypeValidationSettings const&) @ 0x0000000014ccde2d 7. /build/src/Functions/CastOverloadResolver.cpp:128: DB::CastOverloadResolverImpl::getReturnTypeImpl(std::vector> const&) const @ 0x0000000012dcd4a5 8. /build/src/Functions/IFunction.cpp:645: DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x0000000012d96b0c 9. /build/src/Functions/IFunction.cpp:585: DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x0000000012d9665b 10. /build/src/Functions/IFunction.cpp:606: DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x0000000012d96edc 11. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3544: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000014033cc9 12. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3838: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000014019a9e 13. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3980: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000014018e31 14. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:4304: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000014042fa7 15. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5605: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000014013749 16. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000140127f9 17. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000014011fce 18. /build/src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000001406ce8a 19. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000014973b42 20. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000001497268d 21. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000014974d24 22. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001492924b 23. /build/src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88641 24. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 25. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 26. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 27. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 28. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 29. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 30. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 31. ? @ 0x00007fbc6213eac3 2025.07.28 11:51:35.058713 [ 4581 ] {} TCPHandler: Code: 44. DB::Exception: Cannot create column with type 'Variant(String, UInt64)' because Variant type is not allowed. Set setting enable_variant_type = 1 in order to allow it: In scope SELECT CAST('[[[42]]]', 'Array(Array(Array(Variant(String, UInt64))))'). (ILLEGAL_COLUMN), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x000000000a06b56b 4. /build/src/Interpreters/parseColumnsListForTableFunction.cpp:105: DB::validateDataType(std::shared_ptr const&, DB::DataTypeValidationSettings const&)::$_0::operator()(DB::IDataType const&) const @ 0x0000000014cce784 5. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000013bd9034 6. /build/src/Interpreters/parseColumnsListForTableFunction.cpp:173: DB::validateDataType(std::shared_ptr const&, DB::DataTypeValidationSettings const&) @ 0x0000000014ccde2d 7. /build/src/Functions/CastOverloadResolver.cpp:128: DB::CastOverloadResolverImpl::getReturnTypeImpl(std::vector> const&) const @ 0x0000000012dcd4a5 8. /build/src/Functions/IFunction.cpp:645: DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x0000000012d96b0c 9. /build/src/Functions/IFunction.cpp:585: DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x0000000012d9665b 10. /build/src/Functions/IFunction.cpp:606: DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x0000000012d96edc 11. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3544: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000014033cc9 12. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3838: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000014019a9e 13. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3980: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000014018e31 14. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:4304: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000014042fa7 15. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5605: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000014013749 16. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000140127f9 17. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000014011fce 18. /build/src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000001406ce8a 19. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000014973b42 20. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000001497268d 21. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000014974d24 22. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001492924b 23. /build/src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88641 24. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 25. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 26. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 27. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 28. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 29. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 30. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 31. ? @ 0x00007fbc6213eac3 2025.07.28 11:51:35.260012 [ 4581 ] {bae32fdb-1f01-4a5e-a721-37cd83936f4d} executeQuery: Code: 44. DB::Exception: Cannot create column with type 'Variant(String, UInt64)' because Variant type is not allowed. Set setting enable_variant_type = 1 in order to allow it: In scope SELECT CAST(map('a', 42), 'Map(String, Variant(String, UInt64))'). (ILLEGAL_COLUMN) (version 25.3.6.10636.altinitytest (altinity build)) (from [::1]:33012) (comment: 02981_nested_bad_types.sql) (query 31, line 38) (in query: select map('a', 42)::Map(String, Variant(String, UInt64));), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x000000000a06b56b 4. /build/src/Interpreters/parseColumnsListForTableFunction.cpp:105: DB::validateDataType(std::shared_ptr const&, DB::DataTypeValidationSettings const&)::$_0::operator()(DB::IDataType const&) const @ 0x0000000014cce784 5. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000013bf3d4b 6. /build/src/Interpreters/parseColumnsListForTableFunction.cpp:173: DB::validateDataType(std::shared_ptr const&, DB::DataTypeValidationSettings const&) @ 0x0000000014ccde2d 7. /build/src/Functions/CastOverloadResolver.cpp:128: DB::CastOverloadResolverImpl::getReturnTypeImpl(std::vector> const&) const @ 0x0000000012dcd4a5 8. /build/src/Functions/IFunction.cpp:645: DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x0000000012d96b0c 9. /build/src/Functions/IFunction.cpp:585: DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x0000000012d9665b 10. /build/src/Functions/IFunction.cpp:606: DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x0000000012d96edc 11. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3544: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000014033cc9 12. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3838: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000014019a9e 13. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3980: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000014018e31 14. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:4304: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000014042fa7 15. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5605: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000014013749 16. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000140127f9 17. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000014011fce 18. /build/src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000001406ce8a 19. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000014973b42 20. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000001497268d 21. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000014974d24 22. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001492924b 23. /build/src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88641 24. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 25. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 26. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 27. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 28. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 29. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 30. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 31. ? @ 0x00007fbc6213eac3 2025.07.28 11:51:35.269133 [ 4581 ] {} TCPHandler: Code: 44. DB::Exception: Cannot create column with type 'Variant(String, UInt64)' because Variant type is not allowed. Set setting enable_variant_type = 1 in order to allow it: In scope SELECT CAST(map('a', 42), 'Map(String, Variant(String, UInt64))'). (ILLEGAL_COLUMN), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x000000000a06b56b 4. /build/src/Interpreters/parseColumnsListForTableFunction.cpp:105: DB::validateDataType(std::shared_ptr const&, DB::DataTypeValidationSettings const&)::$_0::operator()(DB::IDataType const&) const @ 0x0000000014cce784 5. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000013bf3d4b 6. /build/src/Interpreters/parseColumnsListForTableFunction.cpp:173: DB::validateDataType(std::shared_ptr const&, DB::DataTypeValidationSettings const&) @ 0x0000000014ccde2d 7. /build/src/Functions/CastOverloadResolver.cpp:128: DB::CastOverloadResolverImpl::getReturnTypeImpl(std::vector> const&) const @ 0x0000000012dcd4a5 8. /build/src/Functions/IFunction.cpp:645: DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x0000000012d96b0c 9. /build/src/Functions/IFunction.cpp:585: DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x0000000012d9665b 10. /build/src/Functions/IFunction.cpp:606: DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x0000000012d96edc 11. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3544: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000014033cc9 12. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3838: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000014019a9e 13. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3980: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000014018e31 14. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:4304: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000014042fa7 15. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5605: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000014013749 16. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000140127f9 17. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000014011fce 18. /build/src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000001406ce8a 19. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000014973b42 20. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000001497268d 21. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000014974d24 22. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001492924b 23. /build/src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88641 24. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 25. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 26. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 27. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 28. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 29. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 30. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 31. ? @ 0x00007fbc6213eac3 2025.07.28 11:51:35.342891 [ 4581 ] {bcc14ff9-efe0-448d-ac2c-5da34b34dd9a} executeQuery: Code: 44. DB::Exception: Cannot create column with type 'Variant(String, UInt64)' because Variant type is not allowed. Set setting enable_variant_type = 1 in order to allow it: In scope SELECT CAST(map('a', map('b', [42])), 'Map(String, Map(String, Array(Variant(String, UInt64))))'). (ILLEGAL_COLUMN) (version 25.3.6.10636.altinitytest (altinity build)) (from [::1]:33012) (comment: 02981_nested_bad_types.sql) (query 32, line 39) (in query: select map('a', map('b', [42]))::Map(String, Map(String, Array(Variant(String, UInt64))));), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x000000000a06b56b 4. /build/src/Interpreters/parseColumnsListForTableFunction.cpp:105: DB::validateDataType(std::shared_ptr const&, DB::DataTypeValidationSettings const&)::$_0::operator()(DB::IDataType const&) const @ 0x0000000014cce784 5. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000013bd9034 6. /build/src/Interpreters/parseColumnsListForTableFunction.cpp:173: DB::validateDataType(std::shared_ptr const&, DB::DataTypeValidationSettings const&) @ 0x0000000014ccde2d 7. /build/src/Functions/CastOverloadResolver.cpp:128: DB::CastOverloadResolverImpl::getReturnTypeImpl(std::vector> const&) const @ 0x0000000012dcd4a5 8. /build/src/Functions/IFunction.cpp:645: DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x0000000012d96b0c 9. /build/src/Functions/IFunction.cpp:585: DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x0000000012d9665b 10. /build/src/Functions/IFunction.cpp:606: DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x0000000012d96edc 11. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3544: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000014033cc9 12. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3838: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000014019a9e 13. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3980: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000014018e31 14. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:4304: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000014042fa7 15. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5605: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000014013749 16. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000140127f9 17. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000014011fce 18. /build/src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000001406ce8a 19. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000014973b42 20. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000001497268d 21. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000014974d24 22. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001492924b 23. /build/src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88641 24. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 25. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 26. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 27. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 28. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 29. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 30. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 31. ? @ 0x00007fbc6213eac3 2025.07.28 11:51:35.350557 [ 4581 ] {} TCPHandler: Code: 44. DB::Exception: Cannot create column with type 'Variant(String, UInt64)' because Variant type is not allowed. Set setting enable_variant_type = 1 in order to allow it: In scope SELECT CAST(map('a', map('b', [42])), 'Map(String, Map(String, Array(Variant(String, UInt64))))'). (ILLEGAL_COLUMN), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x000000000a06b56b 4. /build/src/Interpreters/parseColumnsListForTableFunction.cpp:105: DB::validateDataType(std::shared_ptr const&, DB::DataTypeValidationSettings const&)::$_0::operator()(DB::IDataType const&) const @ 0x0000000014cce784 5. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000013bd9034 6. /build/src/Interpreters/parseColumnsListForTableFunction.cpp:173: DB::validateDataType(std::shared_ptr const&, DB::DataTypeValidationSettings const&) @ 0x0000000014ccde2d 7. /build/src/Functions/CastOverloadResolver.cpp:128: DB::CastOverloadResolverImpl::getReturnTypeImpl(std::vector> const&) const @ 0x0000000012dcd4a5 8. /build/src/Functions/IFunction.cpp:645: DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x0000000012d96b0c 9. /build/src/Functions/IFunction.cpp:585: DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x0000000012d9665b 10. /build/src/Functions/IFunction.cpp:606: DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x0000000012d96edc 11. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3544: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000014033cc9 12. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3838: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000014019a9e 13. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3980: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000014018e31 14. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:4304: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000014042fa7 15. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5605: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000014013749 16. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000140127f9 17. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000014011fce 18. /build/src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000001406ce8a 19. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000014973b42 20. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000001497268d 21. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000014974d24 22. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001492924b 23. /build/src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88641 24. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 25. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 26. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 27. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 28. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 29. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 30. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 31. ? @ 0x00007fbc6213eac3 2025.07.28 11:51:35.458626 [ 4581 ] {84695345-467f-49ea-9717-bebd3cc3b073} executeQuery: Code: 44. DB::Exception: Cannot create column with type 'Variant(String, UInt64)' because Variant type is not allowed. Set setting enable_variant_type = 1 in order to allow it: In scope SELECT CAST(('a', 42), 'Tuple(String, Variant(String, UInt64))'). (ILLEGAL_COLUMN) (version 25.3.6.10636.altinitytest (altinity build)) (from [::1]:33012) (comment: 02981_nested_bad_types.sql) (query 33, line 40) (in query: select tuple('a', 42)::Tuple(String, Variant(String, UInt64));), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x000000000a06b56b 4. /build/src/Interpreters/parseColumnsListForTableFunction.cpp:105: DB::validateDataType(std::shared_ptr const&, DB::DataTypeValidationSettings const&)::$_0::operator()(DB::IDataType const&) const @ 0x0000000014cce784 5. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000013c0b669 6. /build/src/Interpreters/parseColumnsListForTableFunction.cpp:173: DB::validateDataType(std::shared_ptr const&, DB::DataTypeValidationSettings const&) @ 0x0000000014ccde2d 7. /build/src/Functions/CastOverloadResolver.cpp:128: DB::CastOverloadResolverImpl::getReturnTypeImpl(std::vector> const&) const @ 0x0000000012dcd4a5 8. /build/src/Functions/IFunction.cpp:645: DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x0000000012d96b0c 9. /build/src/Functions/IFunction.cpp:585: DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x0000000012d9665b 10. /build/src/Functions/IFunction.cpp:606: DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x0000000012d96edc 11. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3544: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000014033cc9 12. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3838: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000014019a9e 13. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3980: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000014018e31 14. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:4304: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000014042fa7 15. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5605: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000014013749 16. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000140127f9 17. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000014011fce 18. /build/src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000001406ce8a 19. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000014973b42 20. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000001497268d 21. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000014974d24 22. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001492924b 23. /build/src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88641 24. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 25. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 26. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 27. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 28. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 29. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 30. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 31. ? @ 0x00007fbc6213eac3 2025.07.28 11:51:35.472336 [ 4581 ] {} TCPHandler: Code: 44. DB::Exception: Cannot create column with type 'Variant(String, UInt64)' because Variant type is not allowed. Set setting enable_variant_type = 1 in order to allow it: In scope SELECT CAST(('a', 42), 'Tuple(String, Variant(String, UInt64))'). (ILLEGAL_COLUMN), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x000000000a06b56b 4. /build/src/Interpreters/parseColumnsListForTableFunction.cpp:105: DB::validateDataType(std::shared_ptr const&, DB::DataTypeValidationSettings const&)::$_0::operator()(DB::IDataType const&) const @ 0x0000000014cce784 5. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000013c0b669 6. /build/src/Interpreters/parseColumnsListForTableFunction.cpp:173: DB::validateDataType(std::shared_ptr const&, DB::DataTypeValidationSettings const&) @ 0x0000000014ccde2d 7. /build/src/Functions/CastOverloadResolver.cpp:128: DB::CastOverloadResolverImpl::getReturnTypeImpl(std::vector> const&) const @ 0x0000000012dcd4a5 8. /build/src/Functions/IFunction.cpp:645: DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x0000000012d96b0c 9. /build/src/Functions/IFunction.cpp:585: DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x0000000012d9665b 10. /build/src/Functions/IFunction.cpp:606: DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x0000000012d96edc 11. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3544: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000014033cc9 12. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3838: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000014019a9e 13. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3980: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000014018e31 14. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:4304: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000014042fa7 15. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5605: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000014013749 16. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000140127f9 17. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000014011fce 18. /build/src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000001406ce8a 19. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000014973b42 20. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000001497268d 21. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000014974d24 22. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001492924b 23. /build/src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88641 24. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 25. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 26. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 27. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 28. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 29. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 30. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 31. ? @ 0x00007fbc6213eac3 2025.07.28 11:51:35.545522 [ 4581 ] {52c1f3e2-7ff3-4986-84dd-7df31a58e4c5} executeQuery: Code: 44. DB::Exception: Cannot create column with type 'Variant(String, UInt64)' because Variant type is not allowed. Set setting enable_variant_type = 1 in order to allow it: In scope SELECT CAST(('a', [map('b', 42)]), 'Tuple(String, Array(Map(String, Variant(String, UInt64))))'). (ILLEGAL_COLUMN) (version 25.3.6.10636.altinitytest (altinity build)) (from [::1]:33012) (comment: 02981_nested_bad_types.sql) (query 34, line 41) (in query: select tuple('a', [map('b', 42)])::Tuple(String, Array(Map(String, Variant(String, UInt64))));), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x000000000a06b56b 4. /build/src/Interpreters/parseColumnsListForTableFunction.cpp:105: DB::validateDataType(std::shared_ptr const&, DB::DataTypeValidationSettings const&)::$_0::operator()(DB::IDataType const&) const @ 0x0000000014cce784 5. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000013bf3d4b 6. /build/src/DataTypes/DataTypeTuple.cpp:413: DB::DataTypeTuple::forEachChild(std::function const&) const @ 0x0000000013c0b675 7. /build/src/Interpreters/parseColumnsListForTableFunction.cpp:173: DB::validateDataType(std::shared_ptr const&, DB::DataTypeValidationSettings const&) @ 0x0000000014ccde2d 8. /build/src/Functions/CastOverloadResolver.cpp:128: DB::CastOverloadResolverImpl::getReturnTypeImpl(std::vector> const&) const @ 0x0000000012dcd4a5 9. /build/src/Functions/IFunction.cpp:645: DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x0000000012d96b0c 10. /build/src/Functions/IFunction.cpp:585: DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x0000000012d9665b 11. /build/src/Functions/IFunction.cpp:606: DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x0000000012d96edc 12. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3544: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000014033cc9 13. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3838: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000014019a9e 14. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3980: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000014018e31 15. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:4304: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000014042fa7 16. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5605: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000014013749 17. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000140127f9 18. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000014011fce 19. /build/src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000001406ce8a 20. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000014973b42 21. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000001497268d 22. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000014974d24 23. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001492924b 24. /build/src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88641 25. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 26. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 27. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 28. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 29. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 30. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 31. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 2025.07.28 11:51:35.553663 [ 4581 ] {} TCPHandler: Code: 44. DB::Exception: Cannot create column with type 'Variant(String, UInt64)' because Variant type is not allowed. Set setting enable_variant_type = 1 in order to allow it: In scope SELECT CAST(('a', [map('b', 42)]), 'Tuple(String, Array(Map(String, Variant(String, UInt64))))'). (ILLEGAL_COLUMN), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x000000000a06b56b 4. /build/src/Interpreters/parseColumnsListForTableFunction.cpp:105: DB::validateDataType(std::shared_ptr const&, DB::DataTypeValidationSettings const&)::$_0::operator()(DB::IDataType const&) const @ 0x0000000014cce784 5. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000013bf3d4b 6. /build/src/DataTypes/DataTypeTuple.cpp:413: DB::DataTypeTuple::forEachChild(std::function const&) const @ 0x0000000013c0b675 7. /build/src/Interpreters/parseColumnsListForTableFunction.cpp:173: DB::validateDataType(std::shared_ptr const&, DB::DataTypeValidationSettings const&) @ 0x0000000014ccde2d 8. /build/src/Functions/CastOverloadResolver.cpp:128: DB::CastOverloadResolverImpl::getReturnTypeImpl(std::vector> const&) const @ 0x0000000012dcd4a5 9. /build/src/Functions/IFunction.cpp:645: DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x0000000012d96b0c 10. /build/src/Functions/IFunction.cpp:585: DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x0000000012d9665b 11. /build/src/Functions/IFunction.cpp:606: DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x0000000012d96edc 12. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3544: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000014033cc9 13. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3838: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000014019a9e 14. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3980: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000014018e31 15. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:4304: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000014042fa7 16. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5605: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000014013749 17. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000140127f9 18. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000014011fce 19. /build/src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000001406ce8a 20. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000014973b42 21. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000001497268d 22. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000014974d24 23. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001492924b 24. /build/src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88641 25. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 26. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 27. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 28. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 29. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 30. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 31. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 2025.07.28 11:51:35.625418 [ 4581 ] {e80e225b-e989-4a4d-88bd-59224d160435} executeQuery: Code: 44. DB::Exception: Cannot create column with type 'Variant(String, UInt64)' because Variant type is not allowed. Set setting enable_variant_type = 1 in order to allow it. (ILLEGAL_COLUMN) (version 25.3.6.10636.altinitytest (altinity build)) (from [::1]:33012) (comment: 02981_nested_bad_types.sql) (query 35, line 43) (in query: create table test (x Array(Variant(String, UInt64))) engine=Memory;), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x000000000a06b56b 4. /build/src/Interpreters/parseColumnsListForTableFunction.cpp:105: DB::validateDataType(std::shared_ptr const&, DB::DataTypeValidationSettings const&)::$_0::operator()(DB::IDataType const&) const @ 0x0000000014cce784 5. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000013bd9034 6. /build/src/Interpreters/parseColumnsListForTableFunction.cpp:173: DB::validateDataType(std::shared_ptr const&, DB::DataTypeValidationSettings const&) @ 0x0000000014ccde2d 7. /build/src/Interpreters/InterpreterCreateQuery.cpp:1037: DB::InterpreterCreateQuery::validateTableStructure(DB::ASTCreateQuery const&, DB::InterpreterCreateQuery::TableProperties const&) const @ 0x00000000148f3cdc 8. /build/src/Interpreters/InterpreterCreateQuery.cpp:1007: DB::InterpreterCreateQuery::getTablePropertiesAndNormalizeCreateQuery(DB::ASTCreateQuery&, DB::LoadingStrictnessLevel) const @ 0x00000000148f0ec3 9. /build/src/Interpreters/InterpreterCreateQuery.cpp:1657: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000148f901b 10. /build/src/Interpreters/InterpreterCreateQuery.cpp:2352: DB::InterpreterCreateQuery::execute() @ 0x0000000014905a41 11. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88dc9 12. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 13. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 14. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 15. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 16. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 17. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 18. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 19. ? @ 0x00007fbc6213eac3 20. ? @ 0x00007fbc621d0850 2025.07.28 11:51:35.631134 [ 4581 ] {} TCPHandler: Code: 44. DB::Exception: Cannot create column with type 'Variant(String, UInt64)' because Variant type is not allowed. Set setting enable_variant_type = 1 in order to allow it. (ILLEGAL_COLUMN), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x000000000a06b56b 4. /build/src/Interpreters/parseColumnsListForTableFunction.cpp:105: DB::validateDataType(std::shared_ptr const&, DB::DataTypeValidationSettings const&)::$_0::operator()(DB::IDataType const&) const @ 0x0000000014cce784 5. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000013bd9034 6. /build/src/Interpreters/parseColumnsListForTableFunction.cpp:173: DB::validateDataType(std::shared_ptr const&, DB::DataTypeValidationSettings const&) @ 0x0000000014ccde2d 7. /build/src/Interpreters/InterpreterCreateQuery.cpp:1037: DB::InterpreterCreateQuery::validateTableStructure(DB::ASTCreateQuery const&, DB::InterpreterCreateQuery::TableProperties const&) const @ 0x00000000148f3cdc 8. /build/src/Interpreters/InterpreterCreateQuery.cpp:1007: DB::InterpreterCreateQuery::getTablePropertiesAndNormalizeCreateQuery(DB::ASTCreateQuery&, DB::LoadingStrictnessLevel) const @ 0x00000000148f0ec3 9. /build/src/Interpreters/InterpreterCreateQuery.cpp:1657: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000148f901b 10. /build/src/Interpreters/InterpreterCreateQuery.cpp:2352: DB::InterpreterCreateQuery::execute() @ 0x0000000014905a41 11. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88dc9 12. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 13. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 14. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 15. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 16. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 17. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 18. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 19. ? @ 0x00007fbc6213eac3 20. ? @ 0x00007fbc621d0850 2025.07.28 11:51:35.703489 [ 4581 ] {a7ab2da5-92c4-4626-b0ea-8e7d5a15deda} executeQuery: Code: 44. DB::Exception: Cannot create column with type 'Variant(String, UInt64)' because Variant type is not allowed. Set setting enable_variant_type = 1 in order to allow it. (ILLEGAL_COLUMN) (version 25.3.6.10636.altinitytest (altinity build)) (from [::1]:33012) (comment: 02981_nested_bad_types.sql) (query 36, line 44) (in query: create table test (x Array(Array(Variant(String, UInt64)))) engine=Memory;), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x000000000a06b56b 4. /build/src/Interpreters/parseColumnsListForTableFunction.cpp:105: DB::validateDataType(std::shared_ptr const&, DB::DataTypeValidationSettings const&)::$_0::operator()(DB::IDataType const&) const @ 0x0000000014cce784 5. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000013bd9034 6. /build/src/Interpreters/parseColumnsListForTableFunction.cpp:173: DB::validateDataType(std::shared_ptr const&, DB::DataTypeValidationSettings const&) @ 0x0000000014ccde2d 7. /build/src/Interpreters/InterpreterCreateQuery.cpp:1037: DB::InterpreterCreateQuery::validateTableStructure(DB::ASTCreateQuery const&, DB::InterpreterCreateQuery::TableProperties const&) const @ 0x00000000148f3cdc 8. /build/src/Interpreters/InterpreterCreateQuery.cpp:1007: DB::InterpreterCreateQuery::getTablePropertiesAndNormalizeCreateQuery(DB::ASTCreateQuery&, DB::LoadingStrictnessLevel) const @ 0x00000000148f0ec3 9. /build/src/Interpreters/InterpreterCreateQuery.cpp:1657: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000148f901b 10. /build/src/Interpreters/InterpreterCreateQuery.cpp:2352: DB::InterpreterCreateQuery::execute() @ 0x0000000014905a41 11. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88dc9 12. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 13. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 14. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 15. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 16. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 17. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 18. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 19. ? @ 0x00007fbc6213eac3 20. ? @ 0x00007fbc621d0850 2025.07.28 11:51:35.707817 [ 4581 ] {} TCPHandler: Code: 44. DB::Exception: Cannot create column with type 'Variant(String, UInt64)' because Variant type is not allowed. Set setting enable_variant_type = 1 in order to allow it. (ILLEGAL_COLUMN), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x000000000a06b56b 4. /build/src/Interpreters/parseColumnsListForTableFunction.cpp:105: DB::validateDataType(std::shared_ptr const&, DB::DataTypeValidationSettings const&)::$_0::operator()(DB::IDataType const&) const @ 0x0000000014cce784 5. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000013bd9034 6. /build/src/Interpreters/parseColumnsListForTableFunction.cpp:173: DB::validateDataType(std::shared_ptr const&, DB::DataTypeValidationSettings const&) @ 0x0000000014ccde2d 7. /build/src/Interpreters/InterpreterCreateQuery.cpp:1037: DB::InterpreterCreateQuery::validateTableStructure(DB::ASTCreateQuery const&, DB::InterpreterCreateQuery::TableProperties const&) const @ 0x00000000148f3cdc 8. /build/src/Interpreters/InterpreterCreateQuery.cpp:1007: DB::InterpreterCreateQuery::getTablePropertiesAndNormalizeCreateQuery(DB::ASTCreateQuery&, DB::LoadingStrictnessLevel) const @ 0x00000000148f0ec3 9. /build/src/Interpreters/InterpreterCreateQuery.cpp:1657: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000148f901b 10. /build/src/Interpreters/InterpreterCreateQuery.cpp:2352: DB::InterpreterCreateQuery::execute() @ 0x0000000014905a41 11. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88dc9 12. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 13. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 14. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 15. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 16. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 17. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 18. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 19. ? @ 0x00007fbc6213eac3 20. ? @ 0x00007fbc621d0850 2025.07.28 11:51:35.781042 [ 4581 ] {dda2de66-fb2a-4cc5-8962-f883c7238516} executeQuery: Code: 44. DB::Exception: Cannot create column with type 'Variant(String, UInt64)' because Variant type is not allowed. Set setting enable_variant_type = 1 in order to allow it. (ILLEGAL_COLUMN) (version 25.3.6.10636.altinitytest (altinity build)) (from [::1]:33012) (comment: 02981_nested_bad_types.sql) (query 37, line 45) (in query: create table test (x Map(String, Variant(String, UInt64))) engine=Memory;), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x000000000a06b56b 4. /build/src/Interpreters/parseColumnsListForTableFunction.cpp:105: DB::validateDataType(std::shared_ptr const&, DB::DataTypeValidationSettings const&)::$_0::operator()(DB::IDataType const&) const @ 0x0000000014cce784 5. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000013bf3d4b 6. /build/src/Interpreters/parseColumnsListForTableFunction.cpp:173: DB::validateDataType(std::shared_ptr const&, DB::DataTypeValidationSettings const&) @ 0x0000000014ccde2d 7. /build/src/Interpreters/InterpreterCreateQuery.cpp:1037: DB::InterpreterCreateQuery::validateTableStructure(DB::ASTCreateQuery const&, DB::InterpreterCreateQuery::TableProperties const&) const @ 0x00000000148f3cdc 8. /build/src/Interpreters/InterpreterCreateQuery.cpp:1007: DB::InterpreterCreateQuery::getTablePropertiesAndNormalizeCreateQuery(DB::ASTCreateQuery&, DB::LoadingStrictnessLevel) const @ 0x00000000148f0ec3 9. /build/src/Interpreters/InterpreterCreateQuery.cpp:1657: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000148f901b 10. /build/src/Interpreters/InterpreterCreateQuery.cpp:2352: DB::InterpreterCreateQuery::execute() @ 0x0000000014905a41 11. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88dc9 12. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 13. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 14. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 15. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 16. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 17. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 18. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 19. ? @ 0x00007fbc6213eac3 20. ? @ 0x00007fbc621d0850 2025.07.28 11:51:35.811699 [ 4581 ] {} TCPHandler: Code: 44. DB::Exception: Cannot create column with type 'Variant(String, UInt64)' because Variant type is not allowed. Set setting enable_variant_type = 1 in order to allow it. (ILLEGAL_COLUMN), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x000000000a06b56b 4. /build/src/Interpreters/parseColumnsListForTableFunction.cpp:105: DB::validateDataType(std::shared_ptr const&, DB::DataTypeValidationSettings const&)::$_0::operator()(DB::IDataType const&) const @ 0x0000000014cce784 5. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000013bf3d4b 6. /build/src/Interpreters/parseColumnsListForTableFunction.cpp:173: DB::validateDataType(std::shared_ptr const&, DB::DataTypeValidationSettings const&) @ 0x0000000014ccde2d 7. /build/src/Interpreters/InterpreterCreateQuery.cpp:1037: DB::InterpreterCreateQuery::validateTableStructure(DB::ASTCreateQuery const&, DB::InterpreterCreateQuery::TableProperties const&) const @ 0x00000000148f3cdc 8. /build/src/Interpreters/InterpreterCreateQuery.cpp:1007: DB::InterpreterCreateQuery::getTablePropertiesAndNormalizeCreateQuery(DB::ASTCreateQuery&, DB::LoadingStrictnessLevel) const @ 0x00000000148f0ec3 9. /build/src/Interpreters/InterpreterCreateQuery.cpp:1657: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000148f901b 10. /build/src/Interpreters/InterpreterCreateQuery.cpp:2352: DB::InterpreterCreateQuery::execute() @ 0x0000000014905a41 11. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88dc9 12. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 13. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 14. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 15. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 16. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 17. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 18. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 19. ? @ 0x00007fbc6213eac3 20. ? @ 0x00007fbc621d0850 2025.07.28 11:51:35.921189 [ 4581 ] {cf2d3560-54ab-4eaf-91d1-fbf3c037ee9e} executeQuery: Code: 44. DB::Exception: Cannot create column with type 'Variant(String, UInt64)' because Variant type is not allowed. Set setting enable_variant_type = 1 in order to allow it. (ILLEGAL_COLUMN) (version 25.3.6.10636.altinitytest (altinity build)) (from [::1]:33012) (comment: 02981_nested_bad_types.sql) (query 38, line 46) (in query: create table test (x Map(String, Map(String, Variant(String, UInt64)))) engine=Memory;), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x000000000a06b56b 4. /build/src/Interpreters/parseColumnsListForTableFunction.cpp:105: DB::validateDataType(std::shared_ptr const&, DB::DataTypeValidationSettings const&)::$_0::operator()(DB::IDataType const&) const @ 0x0000000014cce784 5. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000013bf3d4b 6. /build/src/Interpreters/parseColumnsListForTableFunction.cpp:173: DB::validateDataType(std::shared_ptr const&, DB::DataTypeValidationSettings const&) @ 0x0000000014ccde2d 7. /build/src/Interpreters/InterpreterCreateQuery.cpp:1037: DB::InterpreterCreateQuery::validateTableStructure(DB::ASTCreateQuery const&, DB::InterpreterCreateQuery::TableProperties const&) const @ 0x00000000148f3cdc 8. /build/src/Interpreters/InterpreterCreateQuery.cpp:1007: DB::InterpreterCreateQuery::getTablePropertiesAndNormalizeCreateQuery(DB::ASTCreateQuery&, DB::LoadingStrictnessLevel) const @ 0x00000000148f0ec3 9. /build/src/Interpreters/InterpreterCreateQuery.cpp:1657: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000148f901b 10. /build/src/Interpreters/InterpreterCreateQuery.cpp:2352: DB::InterpreterCreateQuery::execute() @ 0x0000000014905a41 11. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88dc9 12. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 13. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 14. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 15. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 16. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 17. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 18. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 19. ? @ 0x00007fbc6213eac3 20. ? @ 0x00007fbc621d0850 2025.07.28 11:51:35.949786 [ 4581 ] {} TCPHandler: Code: 44. DB::Exception: Cannot create column with type 'Variant(String, UInt64)' because Variant type is not allowed. Set setting enable_variant_type = 1 in order to allow it. (ILLEGAL_COLUMN), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x000000000a06b56b 4. /build/src/Interpreters/parseColumnsListForTableFunction.cpp:105: DB::validateDataType(std::shared_ptr const&, DB::DataTypeValidationSettings const&)::$_0::operator()(DB::IDataType const&) const @ 0x0000000014cce784 5. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000013bf3d4b 6. /build/src/Interpreters/parseColumnsListForTableFunction.cpp:173: DB::validateDataType(std::shared_ptr const&, DB::DataTypeValidationSettings const&) @ 0x0000000014ccde2d 7. /build/src/Interpreters/InterpreterCreateQuery.cpp:1037: DB::InterpreterCreateQuery::validateTableStructure(DB::ASTCreateQuery const&, DB::InterpreterCreateQuery::TableProperties const&) const @ 0x00000000148f3cdc 8. /build/src/Interpreters/InterpreterCreateQuery.cpp:1007: DB::InterpreterCreateQuery::getTablePropertiesAndNormalizeCreateQuery(DB::ASTCreateQuery&, DB::LoadingStrictnessLevel) const @ 0x00000000148f0ec3 9. /build/src/Interpreters/InterpreterCreateQuery.cpp:1657: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000148f901b 10. /build/src/Interpreters/InterpreterCreateQuery.cpp:2352: DB::InterpreterCreateQuery::execute() @ 0x0000000014905a41 11. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88dc9 12. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 13. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 14. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 15. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 16. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 17. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 18. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 19. ? @ 0x00007fbc6213eac3 20. ? @ 0x00007fbc621d0850 2025.07.28 11:51:36.089992 [ 4581 ] {d64775eb-216b-471b-8f59-880f59634a41} executeQuery: Code: 44. DB::Exception: Cannot create column with type 'Variant(String, UInt64)' because Variant type is not allowed. Set setting enable_variant_type = 1 in order to allow it. (ILLEGAL_COLUMN) (version 25.3.6.10636.altinitytest (altinity build)) (from [::1]:33012) (comment: 02981_nested_bad_types.sql) (query 39, line 47) (in query: create table test (x Tuple(String, Variant(String, UInt64))) engine=Memory;), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x000000000a06b56b 4. /build/src/Interpreters/parseColumnsListForTableFunction.cpp:105: DB::validateDataType(std::shared_ptr const&, DB::DataTypeValidationSettings const&)::$_0::operator()(DB::IDataType const&) const @ 0x0000000014cce784 5. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000013c0b669 6. /build/src/Interpreters/parseColumnsListForTableFunction.cpp:173: DB::validateDataType(std::shared_ptr const&, DB::DataTypeValidationSettings const&) @ 0x0000000014ccde2d 7. /build/src/Interpreters/InterpreterCreateQuery.cpp:1037: DB::InterpreterCreateQuery::validateTableStructure(DB::ASTCreateQuery const&, DB::InterpreterCreateQuery::TableProperties const&) const @ 0x00000000148f3cdc 8. /build/src/Interpreters/InterpreterCreateQuery.cpp:1007: DB::InterpreterCreateQuery::getTablePropertiesAndNormalizeCreateQuery(DB::ASTCreateQuery&, DB::LoadingStrictnessLevel) const @ 0x00000000148f0ec3 9. /build/src/Interpreters/InterpreterCreateQuery.cpp:1657: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000148f901b 10. /build/src/Interpreters/InterpreterCreateQuery.cpp:2352: DB::InterpreterCreateQuery::execute() @ 0x0000000014905a41 11. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88dc9 12. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 13. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 14. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 15. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 16. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 17. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 18. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 19. ? @ 0x00007fbc6213eac3 20. ? @ 0x00007fbc621d0850 2025.07.28 11:51:36.132793 [ 4581 ] {} TCPHandler: Code: 44. DB::Exception: Cannot create column with type 'Variant(String, UInt64)' because Variant type is not allowed. Set setting enable_variant_type = 1 in order to allow it. (ILLEGAL_COLUMN), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x000000000a06b56b 4. /build/src/Interpreters/parseColumnsListForTableFunction.cpp:105: DB::validateDataType(std::shared_ptr const&, DB::DataTypeValidationSettings const&)::$_0::operator()(DB::IDataType const&) const @ 0x0000000014cce784 5. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000013c0b669 6. /build/src/Interpreters/parseColumnsListForTableFunction.cpp:173: DB::validateDataType(std::shared_ptr const&, DB::DataTypeValidationSettings const&) @ 0x0000000014ccde2d 7. /build/src/Interpreters/InterpreterCreateQuery.cpp:1037: DB::InterpreterCreateQuery::validateTableStructure(DB::ASTCreateQuery const&, DB::InterpreterCreateQuery::TableProperties const&) const @ 0x00000000148f3cdc 8. /build/src/Interpreters/InterpreterCreateQuery.cpp:1007: DB::InterpreterCreateQuery::getTablePropertiesAndNormalizeCreateQuery(DB::ASTCreateQuery&, DB::LoadingStrictnessLevel) const @ 0x00000000148f0ec3 9. /build/src/Interpreters/InterpreterCreateQuery.cpp:1657: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000148f901b 10. /build/src/Interpreters/InterpreterCreateQuery.cpp:2352: DB::InterpreterCreateQuery::execute() @ 0x0000000014905a41 11. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88dc9 12. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 13. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 14. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 15. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 16. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 17. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 18. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 19. ? @ 0x00007fbc6213eac3 20. ? @ 0x00007fbc621d0850 2025.07.28 11:51:36.196610 [ 11826 ] {ba8ed749-126b-40b6-95ff-5c8956389a5f} executeQuery: Code: 174. DB::Exception: Cyclic aliases: default expression and column type are incompatible. (CYCLIC_ALIASES) (version 25.3.6.10636.altinitytest (altinity build)) (from [::1]:33072) (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. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000000a074fcb 4. /build/src/Interpreters/QueryNormalizer.cpp:109: DB::QueryNormalizer::visit(DB::ASTIdentifier&, std::shared_ptr&, DB::QueryNormalizer::Data&) @ 0x0000000014c3d24b 5. /build/src/Interpreters/QueryNormalizer.cpp:292: DB::QueryNormalizer::visit(std::shared_ptr&, DB::QueryNormalizer::Data&) @ 0x0000000014c3d8e1 6. /build/src/Interpreters/QueryNormalizer.cpp:246: DB::QueryNormalizer::visitChildren(DB::IAST*, DB::QueryNormalizer::Data&) @ 0x0000000014c3e8ac 7. /build/src/Interpreters/QueryNormalizer.cpp:310: DB::QueryNormalizer::visit(std::shared_ptr&, DB::QueryNormalizer::Data&) @ 0x0000000014c3d9c1 8. /build/src/Interpreters/QueryNormalizer.cpp:308: DB::QueryNormalizer::visit(std::shared_ptr&, DB::QueryNormalizer::Data&) @ 0x0000000014c3d9b2 9. /build/src/Interpreters/QueryNormalizer.cpp:246: DB::QueryNormalizer::visitChildren(DB::IAST*, DB::QueryNormalizer::Data&) @ 0x0000000014c3e8ac 10. /build/src/Interpreters/QueryNormalizer.cpp:310: DB::QueryNormalizer::visit(std::shared_ptr&, DB::QueryNormalizer::Data&) @ 0x0000000014c3d9c1 11. /build/src/Interpreters/QueryNormalizer.cpp:308: DB::QueryNormalizer::visit(std::shared_ptr&, DB::QueryNormalizer::Data&) @ 0x0000000014c3d9b2 12. /build/src/Interpreters/QueryNormalizer.cpp:246: DB::QueryNormalizer::visitChildren(DB::IAST*, DB::QueryNormalizer::Data&) @ 0x0000000014c3e8ac 13. /build/src/Interpreters/QueryNormalizer.cpp:310: DB::QueryNormalizer::visit(std::shared_ptr&, DB::QueryNormalizer::Data&) @ 0x0000000014c3d9c1 14. /build/src/Interpreters/QueryNormalizer.cpp:308: DB::QueryNormalizer::visit(std::shared_ptr&, DB::QueryNormalizer::Data&) @ 0x0000000014c3d9b2 15. /build/src/Interpreters/QueryNormalizer.cpp:246: DB::QueryNormalizer::visitChildren(DB::IAST*, DB::QueryNormalizer::Data&) @ 0x0000000014c3e8ac 16. /build/src/Interpreters/QueryNormalizer.cpp:310: DB::QueryNormalizer::visit(std::shared_ptr&, DB::QueryNormalizer::Data&) @ 0x0000000014c3d9c1 17. /build/src/Interpreters/QueryNormalizer.cpp:264: DB::QueryNormalizer::visitChildren(DB::IAST*, DB::QueryNormalizer::Data&) @ 0x0000000014c3e6d4 18. /build/src/Interpreters/QueryNormalizer.cpp:310: DB::QueryNormalizer::visit(std::shared_ptr&, DB::QueryNormalizer::Data&) @ 0x0000000014c3d9c1 19. /build/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) @ 0x0000000014c08c90 20. /build/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 @ 0x0000000014c0a014 21. /build/src/Storages/ColumnsDescription.cpp:1017: DB::(anonymous namespace)::validateColumnsDefaultsAndGetSampleBlockImpl(std::shared_ptr, DB::NamesAndTypesList const&, std::shared_ptr, bool) @ 0x0000000015d07a0e 22. /build/src/Storages/ColumnsDescription.cpp:1044: DB::validateColumnsDefaultsAndGetSampleBlock(std::shared_ptr, DB::NamesAndTypesList const&, std::shared_ptr) @ 0x0000000015d07ee6 23. /build/src/Interpreters/InterpreterCreateQuery.cpp:639: DB::InterpreterCreateQuery::getColumnsDescription(DB::ASTExpressionList const&, std::shared_ptr, DB::LoadingStrictnessLevel, bool) @ 0x00000000148ec902 24. /build/src/Interpreters/InterpreterCreateQuery.cpp:784: DB::InterpreterCreateQuery::getTablePropertiesAndNormalizeCreateQuery(DB::ASTCreateQuery&, DB::LoadingStrictnessLevel) const @ 0x00000000148ee1e4 25. /build/src/Interpreters/InterpreterCreateQuery.cpp:1657: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000148f901b 26. /build/src/Interpreters/InterpreterCreateQuery.cpp:2352: DB::InterpreterCreateQuery::execute() @ 0x0000000014905a41 27. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88dc9 28. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 29. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 30. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 31. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 2025.07.28 11:51:36.210223 [ 11826 ] {} 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. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000000a074fcb 4. /build/src/Interpreters/QueryNormalizer.cpp:109: DB::QueryNormalizer::visit(DB::ASTIdentifier&, std::shared_ptr&, DB::QueryNormalizer::Data&) @ 0x0000000014c3d24b 5. /build/src/Interpreters/QueryNormalizer.cpp:292: DB::QueryNormalizer::visit(std::shared_ptr&, DB::QueryNormalizer::Data&) @ 0x0000000014c3d8e1 6. /build/src/Interpreters/QueryNormalizer.cpp:246: DB::QueryNormalizer::visitChildren(DB::IAST*, DB::QueryNormalizer::Data&) @ 0x0000000014c3e8ac 7. /build/src/Interpreters/QueryNormalizer.cpp:310: DB::QueryNormalizer::visit(std::shared_ptr&, DB::QueryNormalizer::Data&) @ 0x0000000014c3d9c1 8. /build/src/Interpreters/QueryNormalizer.cpp:308: DB::QueryNormalizer::visit(std::shared_ptr&, DB::QueryNormalizer::Data&) @ 0x0000000014c3d9b2 9. /build/src/Interpreters/QueryNormalizer.cpp:246: DB::QueryNormalizer::visitChildren(DB::IAST*, DB::QueryNormalizer::Data&) @ 0x0000000014c3e8ac 10. /build/src/Interpreters/QueryNormalizer.cpp:310: DB::QueryNormalizer::visit(std::shared_ptr&, DB::QueryNormalizer::Data&) @ 0x0000000014c3d9c1 11. /build/src/Interpreters/QueryNormalizer.cpp:308: DB::QueryNormalizer::visit(std::shared_ptr&, DB::QueryNormalizer::Data&) @ 0x0000000014c3d9b2 12. /build/src/Interpreters/QueryNormalizer.cpp:246: DB::QueryNormalizer::visitChildren(DB::IAST*, DB::QueryNormalizer::Data&) @ 0x0000000014c3e8ac 13. /build/src/Interpreters/QueryNormalizer.cpp:310: DB::QueryNormalizer::visit(std::shared_ptr&, DB::QueryNormalizer::Data&) @ 0x0000000014c3d9c1 14. /build/src/Interpreters/QueryNormalizer.cpp:308: DB::QueryNormalizer::visit(std::shared_ptr&, DB::QueryNormalizer::Data&) @ 0x0000000014c3d9b2 15. /build/src/Interpreters/QueryNormalizer.cpp:246: DB::QueryNormalizer::visitChildren(DB::IAST*, DB::QueryNormalizer::Data&) @ 0x0000000014c3e8ac 16. /build/src/Interpreters/QueryNormalizer.cpp:310: DB::QueryNormalizer::visit(std::shared_ptr&, DB::QueryNormalizer::Data&) @ 0x0000000014c3d9c1 17. /build/src/Interpreters/QueryNormalizer.cpp:264: DB::QueryNormalizer::visitChildren(DB::IAST*, DB::QueryNormalizer::Data&) @ 0x0000000014c3e6d4 18. /build/src/Interpreters/QueryNormalizer.cpp:310: DB::QueryNormalizer::visit(std::shared_ptr&, DB::QueryNormalizer::Data&) @ 0x0000000014c3d9c1 19. /build/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) @ 0x0000000014c08c90 20. /build/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 @ 0x0000000014c0a014 21. /build/src/Storages/ColumnsDescription.cpp:1017: DB::(anonymous namespace)::validateColumnsDefaultsAndGetSampleBlockImpl(std::shared_ptr, DB::NamesAndTypesList const&, std::shared_ptr, bool) @ 0x0000000015d07a0e 22. /build/src/Storages/ColumnsDescription.cpp:1044: DB::validateColumnsDefaultsAndGetSampleBlock(std::shared_ptr, DB::NamesAndTypesList const&, std::shared_ptr) @ 0x0000000015d07ee6 23. /build/src/Interpreters/InterpreterCreateQuery.cpp:639: DB::InterpreterCreateQuery::getColumnsDescription(DB::ASTExpressionList const&, std::shared_ptr, DB::LoadingStrictnessLevel, bool) @ 0x00000000148ec902 24. /build/src/Interpreters/InterpreterCreateQuery.cpp:784: DB::InterpreterCreateQuery::getTablePropertiesAndNormalizeCreateQuery(DB::ASTCreateQuery&, DB::LoadingStrictnessLevel) const @ 0x00000000148ee1e4 25. /build/src/Interpreters/InterpreterCreateQuery.cpp:1657: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000148f901b 26. /build/src/Interpreters/InterpreterCreateQuery.cpp:2352: DB::InterpreterCreateQuery::execute() @ 0x0000000014905a41 27. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88dc9 28. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 29. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 30. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 31. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 2025.07.28 11:51:36.224212 [ 4581 ] {289c1ea4-e8d7-4323-8606-b357161a7bd8} executeQuery: Code: 44. DB::Exception: Cannot create column with type 'Variant(String, UInt64)' because Variant type is not allowed. Set setting enable_variant_type = 1 in order to allow it. (ILLEGAL_COLUMN) (version 25.3.6.10636.altinitytest (altinity build)) (from [::1]:33012) (comment: 02981_nested_bad_types.sql) (query 40, line 48) (in query: create table test (x Tuple(String, Array(Map(String, Variant(String, UInt64))))) engine=Memory;), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x000000000a06b56b 4. /build/src/Interpreters/parseColumnsListForTableFunction.cpp:105: DB::validateDataType(std::shared_ptr const&, DB::DataTypeValidationSettings const&)::$_0::operator()(DB::IDataType const&) const @ 0x0000000014cce784 5. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000013bf3d4b 6. /build/src/DataTypes/DataTypeTuple.cpp:413: DB::DataTypeTuple::forEachChild(std::function const&) const @ 0x0000000013c0b675 7. /build/src/Interpreters/parseColumnsListForTableFunction.cpp:173: DB::validateDataType(std::shared_ptr const&, DB::DataTypeValidationSettings const&) @ 0x0000000014ccde2d 8. /build/src/Interpreters/InterpreterCreateQuery.cpp:1037: DB::InterpreterCreateQuery::validateTableStructure(DB::ASTCreateQuery const&, DB::InterpreterCreateQuery::TableProperties const&) const @ 0x00000000148f3cdc 9. /build/src/Interpreters/InterpreterCreateQuery.cpp:1007: DB::InterpreterCreateQuery::getTablePropertiesAndNormalizeCreateQuery(DB::ASTCreateQuery&, DB::LoadingStrictnessLevel) const @ 0x00000000148f0ec3 10. /build/src/Interpreters/InterpreterCreateQuery.cpp:1657: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000148f901b 11. /build/src/Interpreters/InterpreterCreateQuery.cpp:2352: DB::InterpreterCreateQuery::execute() @ 0x0000000014905a41 12. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88dc9 13. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 14. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 15. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 16. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 17. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 18. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 19. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 20. ? @ 0x00007fbc6213eac3 21. ? @ 0x00007fbc621d0850 2025.07.28 11:51:36.253850 [ 4581 ] {} TCPHandler: Code: 44. DB::Exception: Cannot create column with type 'Variant(String, UInt64)' because Variant type is not allowed. Set setting enable_variant_type = 1 in order to allow it. (ILLEGAL_COLUMN), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x000000000a06b56b 4. /build/src/Interpreters/parseColumnsListForTableFunction.cpp:105: DB::validateDataType(std::shared_ptr const&, DB::DataTypeValidationSettings const&)::$_0::operator()(DB::IDataType const&) const @ 0x0000000014cce784 5. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000013bf3d4b 6. /build/src/DataTypes/DataTypeTuple.cpp:413: DB::DataTypeTuple::forEachChild(std::function const&) const @ 0x0000000013c0b675 7. /build/src/Interpreters/parseColumnsListForTableFunction.cpp:173: DB::validateDataType(std::shared_ptr const&, DB::DataTypeValidationSettings const&) @ 0x0000000014ccde2d 8. /build/src/Interpreters/InterpreterCreateQuery.cpp:1037: DB::InterpreterCreateQuery::validateTableStructure(DB::ASTCreateQuery const&, DB::InterpreterCreateQuery::TableProperties const&) const @ 0x00000000148f3cdc 9. /build/src/Interpreters/InterpreterCreateQuery.cpp:1007: DB::InterpreterCreateQuery::getTablePropertiesAndNormalizeCreateQuery(DB::ASTCreateQuery&, DB::LoadingStrictnessLevel) const @ 0x00000000148f0ec3 10. /build/src/Interpreters/InterpreterCreateQuery.cpp:1657: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000148f901b 11. /build/src/Interpreters/InterpreterCreateQuery.cpp:2352: DB::InterpreterCreateQuery::execute() @ 0x0000000014905a41 12. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88dc9 13. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 14. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 15. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 16. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 17. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 18. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 19. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 20. ? @ 0x00007fbc6213eac3 21. ? @ 0x00007fbc621d0850 2025.07.28 11:51:36.467046 [ 11826 ] {a590d542-9924-4801-8a34-61095f125569} executeQuery: Code: 174. DB::Exception: Cyclic aliases: default expression and column type are incompatible. (CYCLIC_ALIASES) (version 25.3.6.10636.altinitytest (altinity build)) (from [::1]:33072) (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. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000000a074fcb 4. /build/src/Interpreters/QueryNormalizer.cpp:109: DB::QueryNormalizer::visit(DB::ASTIdentifier&, std::shared_ptr&, DB::QueryNormalizer::Data&) @ 0x0000000014c3d24b 5. /build/src/Interpreters/QueryNormalizer.cpp:292: DB::QueryNormalizer::visit(std::shared_ptr&, DB::QueryNormalizer::Data&) @ 0x0000000014c3d8e1 6. /build/src/Interpreters/QueryNormalizer.cpp:246: DB::QueryNormalizer::visitChildren(DB::IAST*, DB::QueryNormalizer::Data&) @ 0x0000000014c3e8ac 7. /build/src/Interpreters/QueryNormalizer.cpp:310: DB::QueryNormalizer::visit(std::shared_ptr&, DB::QueryNormalizer::Data&) @ 0x0000000014c3d9c1 8. /build/src/Interpreters/QueryNormalizer.cpp:246: DB::QueryNormalizer::visitChildren(DB::IAST*, DB::QueryNormalizer::Data&) @ 0x0000000014c3e8ac 9. /build/src/Interpreters/QueryNormalizer.cpp:310: DB::QueryNormalizer::visit(std::shared_ptr&, DB::QueryNormalizer::Data&) @ 0x0000000014c3d9c1 10. /build/src/Interpreters/QueryNormalizer.cpp:246: DB::QueryNormalizer::visitChildren(DB::IAST*, DB::QueryNormalizer::Data&) @ 0x0000000014c3e8ac 11. /build/src/Interpreters/QueryNormalizer.cpp:310: DB::QueryNormalizer::visit(std::shared_ptr&, DB::QueryNormalizer::Data&) @ 0x0000000014c3d9c1 12. /build/src/Interpreters/QueryNormalizer.cpp:308: DB::QueryNormalizer::visit(std::shared_ptr&, DB::QueryNormalizer::Data&) @ 0x0000000014c3d9b2 13. /build/src/Interpreters/QueryNormalizer.cpp:246: DB::QueryNormalizer::visitChildren(DB::IAST*, DB::QueryNormalizer::Data&) @ 0x0000000014c3e8ac 14. /build/src/Interpreters/QueryNormalizer.cpp:310: DB::QueryNormalizer::visit(std::shared_ptr&, DB::QueryNormalizer::Data&) @ 0x0000000014c3d9c1 15. /build/src/Interpreters/QueryNormalizer.cpp:308: DB::QueryNormalizer::visit(std::shared_ptr&, DB::QueryNormalizer::Data&) @ 0x0000000014c3d9b2 16. /build/src/Interpreters/QueryNormalizer.cpp:246: DB::QueryNormalizer::visitChildren(DB::IAST*, DB::QueryNormalizer::Data&) @ 0x0000000014c3e8ac 17. /build/src/Interpreters/QueryNormalizer.cpp:310: DB::QueryNormalizer::visit(std::shared_ptr&, DB::QueryNormalizer::Data&) @ 0x0000000014c3d9c1 18. /build/src/Interpreters/QueryNormalizer.cpp:246: DB::QueryNormalizer::visitChildren(DB::IAST*, DB::QueryNormalizer::Data&) @ 0x0000000014c3e8ac 19. /build/src/Interpreters/QueryNormalizer.cpp:310: DB::QueryNormalizer::visit(std::shared_ptr&, DB::QueryNormalizer::Data&) @ 0x0000000014c3d9c1 20. /build/src/Interpreters/QueryNormalizer.cpp:246: DB::QueryNormalizer::visitChildren(DB::IAST*, DB::QueryNormalizer::Data&) @ 0x0000000014c3e8ac 21. /build/src/Interpreters/QueryNormalizer.cpp:310: DB::QueryNormalizer::visit(std::shared_ptr&, DB::QueryNormalizer::Data&) @ 0x0000000014c3d9c1 22. /build/src/Interpreters/QueryNormalizer.cpp:308: DB::QueryNormalizer::visit(std::shared_ptr&, DB::QueryNormalizer::Data&) @ 0x0000000014c3d9b2 23. /build/src/Interpreters/QueryNormalizer.cpp:246: DB::QueryNormalizer::visitChildren(DB::IAST*, DB::QueryNormalizer::Data&) @ 0x0000000014c3e8ac 24. /build/src/Interpreters/QueryNormalizer.cpp:310: DB::QueryNormalizer::visit(std::shared_ptr&, DB::QueryNormalizer::Data&) @ 0x0000000014c3d9c1 25. /build/src/Interpreters/QueryNormalizer.cpp:264: DB::QueryNormalizer::visitChildren(DB::IAST*, DB::QueryNormalizer::Data&) @ 0x0000000014c3e6d4 26. /build/src/Interpreters/QueryNormalizer.cpp:310: DB::QueryNormalizer::visit(std::shared_ptr&, DB::QueryNormalizer::Data&) @ 0x0000000014c3d9c1 27. /build/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) @ 0x0000000014c08c90 28. /build/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 @ 0x0000000014c0a014 29. /build/src/Storages/ColumnsDescription.cpp:1017: DB::(anonymous namespace)::validateColumnsDefaultsAndGetSampleBlockImpl(std::shared_ptr, DB::NamesAndTypesList const&, std::shared_ptr, bool) @ 0x0000000015d07a0e 30. /build/src/Storages/ColumnsDescription.cpp:1044: DB::validateColumnsDefaultsAndGetSampleBlock(std::shared_ptr, DB::NamesAndTypesList const&, std::shared_ptr) @ 0x0000000015d07ee6 31. /build/src/Interpreters/InterpreterCreateQuery.cpp:639: DB::InterpreterCreateQuery::getColumnsDescription(DB::ASTExpressionList const&, std::shared_ptr, DB::LoadingStrictnessLevel, bool) @ 0x00000000148ec902 2025.07.28 11:51:36.470176 [ 11826 ] {} 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. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000000a074fcb 4. /build/src/Interpreters/QueryNormalizer.cpp:109: DB::QueryNormalizer::visit(DB::ASTIdentifier&, std::shared_ptr&, DB::QueryNormalizer::Data&) @ 0x0000000014c3d24b 5. /build/src/Interpreters/QueryNormalizer.cpp:292: DB::QueryNormalizer::visit(std::shared_ptr&, DB::QueryNormalizer::Data&) @ 0x0000000014c3d8e1 6. /build/src/Interpreters/QueryNormalizer.cpp:246: DB::QueryNormalizer::visitChildren(DB::IAST*, DB::QueryNormalizer::Data&) @ 0x0000000014c3e8ac 7. /build/src/Interpreters/QueryNormalizer.cpp:310: DB::QueryNormalizer::visit(std::shared_ptr&, DB::QueryNormalizer::Data&) @ 0x0000000014c3d9c1 8. /build/src/Interpreters/QueryNormalizer.cpp:246: DB::QueryNormalizer::visitChildren(DB::IAST*, DB::QueryNormalizer::Data&) @ 0x0000000014c3e8ac 9. /build/src/Interpreters/QueryNormalizer.cpp:310: DB::QueryNormalizer::visit(std::shared_ptr&, DB::QueryNormalizer::Data&) @ 0x0000000014c3d9c1 10. /build/src/Interpreters/QueryNormalizer.cpp:246: DB::QueryNormalizer::visitChildren(DB::IAST*, DB::QueryNormalizer::Data&) @ 0x0000000014c3e8ac 11. /build/src/Interpreters/QueryNormalizer.cpp:310: DB::QueryNormalizer::visit(std::shared_ptr&, DB::QueryNormalizer::Data&) @ 0x0000000014c3d9c1 12. /build/src/Interpreters/QueryNormalizer.cpp:308: DB::QueryNormalizer::visit(std::shared_ptr&, DB::QueryNormalizer::Data&) @ 0x0000000014c3d9b2 13. /build/src/Interpreters/QueryNormalizer.cpp:246: DB::QueryNormalizer::visitChildren(DB::IAST*, DB::QueryNormalizer::Data&) @ 0x0000000014c3e8ac 14. /build/src/Interpreters/QueryNormalizer.cpp:310: DB::QueryNormalizer::visit(std::shared_ptr&, DB::QueryNormalizer::Data&) @ 0x0000000014c3d9c1 15. /build/src/Interpreters/QueryNormalizer.cpp:308: DB::QueryNormalizer::visit(std::shared_ptr&, DB::QueryNormalizer::Data&) @ 0x0000000014c3d9b2 16. /build/src/Interpreters/QueryNormalizer.cpp:246: DB::QueryNormalizer::visitChildren(DB::IAST*, DB::QueryNormalizer::Data&) @ 0x0000000014c3e8ac 17. /build/src/Interpreters/QueryNormalizer.cpp:310: DB::QueryNormalizer::visit(std::shared_ptr&, DB::QueryNormalizer::Data&) @ 0x0000000014c3d9c1 18. /build/src/Interpreters/QueryNormalizer.cpp:246: DB::QueryNormalizer::visitChildren(DB::IAST*, DB::QueryNormalizer::Data&) @ 0x0000000014c3e8ac 19. /build/src/Interpreters/QueryNormalizer.cpp:310: DB::QueryNormalizer::visit(std::shared_ptr&, DB::QueryNormalizer::Data&) @ 0x0000000014c3d9c1 20. /build/src/Interpreters/QueryNormalizer.cpp:246: DB::QueryNormalizer::visitChildren(DB::IAST*, DB::QueryNormalizer::Data&) @ 0x0000000014c3e8ac 21. /build/src/Interpreters/QueryNormalizer.cpp:310: DB::QueryNormalizer::visit(std::shared_ptr&, DB::QueryNormalizer::Data&) @ 0x0000000014c3d9c1 22. /build/src/Interpreters/QueryNormalizer.cpp:308: DB::QueryNormalizer::visit(std::shared_ptr&, DB::QueryNormalizer::Data&) @ 0x0000000014c3d9b2 23. /build/src/Interpreters/QueryNormalizer.cpp:246: DB::QueryNormalizer::visitChildren(DB::IAST*, DB::QueryNormalizer::Data&) @ 0x0000000014c3e8ac 24. /build/src/Interpreters/QueryNormalizer.cpp:310: DB::QueryNormalizer::visit(std::shared_ptr&, DB::QueryNormalizer::Data&) @ 0x0000000014c3d9c1 25. /build/src/Interpreters/QueryNormalizer.cpp:264: DB::QueryNormalizer::visitChildren(DB::IAST*, DB::QueryNormalizer::Data&) @ 0x0000000014c3e6d4 26. /build/src/Interpreters/QueryNormalizer.cpp:310: DB::QueryNormalizer::visit(std::shared_ptr&, DB::QueryNormalizer::Data&) @ 0x0000000014c3d9c1 27. /build/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) @ 0x0000000014c08c90 28. /build/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 @ 0x0000000014c0a014 29. /build/src/Storages/ColumnsDescription.cpp:1017: DB::(anonymous namespace)::validateColumnsDefaultsAndGetSampleBlockImpl(std::shared_ptr, DB::NamesAndTypesList const&, std::shared_ptr, bool) @ 0x0000000015d07a0e 30. /build/src/Storages/ColumnsDescription.cpp:1044: DB::validateColumnsDefaultsAndGetSampleBlock(std::shared_ptr, DB::NamesAndTypesList const&, std::shared_ptr) @ 0x0000000015d07ee6 31. /build/src/Interpreters/InterpreterCreateQuery.cpp:639: DB::InterpreterCreateQuery::getColumnsDescription(DB::ASTExpressionList const&, std::shared_ptr, DB::LoadingStrictnessLevel, bool) @ 0x00000000148ec902 2025.07.28 11:51:36.496550 [ 4581 ] {11c3e84f-5ecd-4696-bf94-38bacd612e18} 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('42', 'Variant(String, LowCardinality(UInt64))') SETTINGS allow_experimental_variant_type = 1. (SUSPICIOUS_TYPE_FOR_LOW_CARDINALITY) (version 25.3.6.10636.altinitytest (altinity build)) (from [::1]:33012) (comment: 02981_nested_bad_types.sql) (query 42, line 51) (in query: select 42::Variant(String, LowCardinality(UInt64)) settings allow_experimental_variant_type=1;), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x000000000a06b56b 4. /build/src/Interpreters/parseColumnsListForTableFunction.cpp:67: DB::validateDataType(std::shared_ptr const&, DB::DataTypeValidationSettings const&)::$_0::operator()(DB::IDataType const&) const @ 0x0000000014ccea0b 5. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000013c0e9c9 6. /build/src/Interpreters/parseColumnsListForTableFunction.cpp:173: DB::validateDataType(std::shared_ptr const&, DB::DataTypeValidationSettings const&) @ 0x0000000014ccde2d 7. /build/src/Functions/CastOverloadResolver.cpp:128: DB::CastOverloadResolverImpl::getReturnTypeImpl(std::vector> const&) const @ 0x0000000012dcd4a5 8. /build/src/Functions/IFunction.cpp:645: DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x0000000012d96b0c 9. /build/src/Functions/IFunction.cpp:585: DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x0000000012d9665b 10. /build/src/Functions/IFunction.cpp:606: DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x0000000012d96edc 11. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3544: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000014033cc9 12. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3838: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000014019a9e 13. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3980: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000014018e31 14. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:4304: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000014042fa7 15. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5605: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000014013749 16. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000140127f9 17. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000014011fce 18. /build/src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000001406ce8a 19. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000014973b42 20. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000001497268d 21. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000014974d24 22. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001492924b 23. /build/src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88641 24. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 25. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 26. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 27. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 28. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 29. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 30. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 31. ? @ 0x00007fbc6213eac3 2025.07.28 11:51:36.507608 [ 4581 ] {} 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('42', 'Variant(String, LowCardinality(UInt64))') SETTINGS allow_experimental_variant_type = 1. (SUSPICIOUS_TYPE_FOR_LOW_CARDINALITY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x000000000a06b56b 4. /build/src/Interpreters/parseColumnsListForTableFunction.cpp:67: DB::validateDataType(std::shared_ptr const&, DB::DataTypeValidationSettings const&)::$_0::operator()(DB::IDataType const&) const @ 0x0000000014ccea0b 5. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000013c0e9c9 6. /build/src/Interpreters/parseColumnsListForTableFunction.cpp:173: DB::validateDataType(std::shared_ptr const&, DB::DataTypeValidationSettings const&) @ 0x0000000014ccde2d 7. /build/src/Functions/CastOverloadResolver.cpp:128: DB::CastOverloadResolverImpl::getReturnTypeImpl(std::vector> const&) const @ 0x0000000012dcd4a5 8. /build/src/Functions/IFunction.cpp:645: DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x0000000012d96b0c 9. /build/src/Functions/IFunction.cpp:585: DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x0000000012d9665b 10. /build/src/Functions/IFunction.cpp:606: DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x0000000012d96edc 11. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3544: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000014033cc9 12. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3838: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000014019a9e 13. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3980: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000014018e31 14. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:4304: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000014042fa7 15. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5605: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000014013749 16. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000140127f9 17. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000014011fce 18. /build/src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000001406ce8a 19. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000014973b42 20. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000001497268d 21. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000014974d24 22. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001492924b 23. /build/src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88641 24. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 25. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 26. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 27. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 28. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 29. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 30. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 31. ? @ 0x00007fbc6213eac3 2025.07.28 11:51:36.705513 [ 4581 ] {6f11d841-cc49-422c-a034-bb547a4479b6} 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(('a', [map('b', 42)]), 'Tuple(String, Array(Map(String, Variant(LowCardinality(UInt64), String))))'). (SUSPICIOUS_TYPE_FOR_LOW_CARDINALITY) (version 25.3.6.10636.altinitytest (altinity build)) (from [::1]:33012) (comment: 02981_nested_bad_types.sql) (query 43, line 52) (in query: select tuple('a', [map('b', 42)])::Tuple(String, Array(Map(String, Variant(LowCardinality(UInt64), String))));), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x000000000a06b56b 4. /build/src/Interpreters/parseColumnsListForTableFunction.cpp:67: DB::validateDataType(std::shared_ptr const&, DB::DataTypeValidationSettings const&)::$_0::operator()(DB::IDataType const&) const @ 0x0000000014ccea0b 5. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000013c0e9c9 6. /build/src/DataTypes/DataTypeTuple.cpp:413: DB::DataTypeTuple::forEachChild(std::function const&) const @ 0x0000000013c0b675 7. /build/src/Interpreters/parseColumnsListForTableFunction.cpp:173: DB::validateDataType(std::shared_ptr const&, DB::DataTypeValidationSettings const&) @ 0x0000000014ccde2d 8. /build/src/Functions/CastOverloadResolver.cpp:128: DB::CastOverloadResolverImpl::getReturnTypeImpl(std::vector> const&) const @ 0x0000000012dcd4a5 9. /build/src/Functions/IFunction.cpp:645: DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x0000000012d96b0c 10. /build/src/Functions/IFunction.cpp:585: DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x0000000012d9665b 11. /build/src/Functions/IFunction.cpp:606: DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x0000000012d96edc 12. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3544: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000014033cc9 13. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3838: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000014019a9e 14. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3980: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000014018e31 15. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:4304: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000014042fa7 16. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5605: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000014013749 17. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000140127f9 18. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000014011fce 19. /build/src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000001406ce8a 20. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000014973b42 21. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000001497268d 22. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000014974d24 23. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001492924b 24. /build/src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88641 25. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 26. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 27. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 28. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 29. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 30. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 31. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 2025.07.28 11:51:36.732480 [ 4581 ] {} 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(('a', [map('b', 42)]), 'Tuple(String, Array(Map(String, Variant(LowCardinality(UInt64), String))))'). (SUSPICIOUS_TYPE_FOR_LOW_CARDINALITY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x000000000a06b56b 4. /build/src/Interpreters/parseColumnsListForTableFunction.cpp:67: DB::validateDataType(std::shared_ptr const&, DB::DataTypeValidationSettings const&)::$_0::operator()(DB::IDataType const&) const @ 0x0000000014ccea0b 5. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000013c0e9c9 6. /build/src/DataTypes/DataTypeTuple.cpp:413: DB::DataTypeTuple::forEachChild(std::function const&) const @ 0x0000000013c0b675 7. /build/src/Interpreters/parseColumnsListForTableFunction.cpp:173: DB::validateDataType(std::shared_ptr const&, DB::DataTypeValidationSettings const&) @ 0x0000000014ccde2d 8. /build/src/Functions/CastOverloadResolver.cpp:128: DB::CastOverloadResolverImpl::getReturnTypeImpl(std::vector> const&) const @ 0x0000000012dcd4a5 9. /build/src/Functions/IFunction.cpp:645: DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x0000000012d96b0c 10. /build/src/Functions/IFunction.cpp:585: DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x0000000012d9665b 11. /build/src/Functions/IFunction.cpp:606: DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x0000000012d96edc 12. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3544: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000014033cc9 13. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3838: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000014019a9e 14. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3980: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000014018e31 15. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:4304: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000014042fa7 16. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5605: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000014013749 17. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000140127f9 18. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000014011fce 19. /build/src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000001406ce8a 20. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000014973b42 21. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000001497268d 22. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000014974d24 23. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001492924b 24. /build/src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88641 25. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 26. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 27. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 28. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 29. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 30. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 31. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 2025.07.28 11:51:36.900070 [ 4581 ] {ac727e4d-dca5-48e3-8697-57a61b5462bf} 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.6.10636.altinitytest (altinity build)) (from [::1]:33012) (comment: 02981_nested_bad_types.sql) (query 44, line 53) (in query: create table test (x Variant(LowCardinality(UInt64), String)) engine=Memory;), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x000000000a06b56b 4. /build/src/Interpreters/parseColumnsListForTableFunction.cpp:67: DB::validateDataType(std::shared_ptr const&, DB::DataTypeValidationSettings const&)::$_0::operator()(DB::IDataType const&) const @ 0x0000000014ccea0b 5. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000013c0e9c9 6. /build/src/Interpreters/parseColumnsListForTableFunction.cpp:173: DB::validateDataType(std::shared_ptr const&, DB::DataTypeValidationSettings const&) @ 0x0000000014ccde2d 7. /build/src/Interpreters/InterpreterCreateQuery.cpp:1037: DB::InterpreterCreateQuery::validateTableStructure(DB::ASTCreateQuery const&, DB::InterpreterCreateQuery::TableProperties const&) const @ 0x00000000148f3cdc 8. /build/src/Interpreters/InterpreterCreateQuery.cpp:1007: DB::InterpreterCreateQuery::getTablePropertiesAndNormalizeCreateQuery(DB::ASTCreateQuery&, DB::LoadingStrictnessLevel) const @ 0x00000000148f0ec3 9. /build/src/Interpreters/InterpreterCreateQuery.cpp:1657: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000148f901b 10. /build/src/Interpreters/InterpreterCreateQuery.cpp:2352: DB::InterpreterCreateQuery::execute() @ 0x0000000014905a41 11. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88dc9 12. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 13. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 14. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 15. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 16. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 17. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 18. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 19. ? @ 0x00007fbc6213eac3 20. ? @ 0x00007fbc621d0850 2025.07.28 11:51:36.909639 [ 4581 ] {} 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. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x000000000a06b56b 4. /build/src/Interpreters/parseColumnsListForTableFunction.cpp:67: DB::validateDataType(std::shared_ptr const&, DB::DataTypeValidationSettings const&)::$_0::operator()(DB::IDataType const&) const @ 0x0000000014ccea0b 5. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000013c0e9c9 6. /build/src/Interpreters/parseColumnsListForTableFunction.cpp:173: DB::validateDataType(std::shared_ptr const&, DB::DataTypeValidationSettings const&) @ 0x0000000014ccde2d 7. /build/src/Interpreters/InterpreterCreateQuery.cpp:1037: DB::InterpreterCreateQuery::validateTableStructure(DB::ASTCreateQuery const&, DB::InterpreterCreateQuery::TableProperties const&) const @ 0x00000000148f3cdc 8. /build/src/Interpreters/InterpreterCreateQuery.cpp:1007: DB::InterpreterCreateQuery::getTablePropertiesAndNormalizeCreateQuery(DB::ASTCreateQuery&, DB::LoadingStrictnessLevel) const @ 0x00000000148f0ec3 9. /build/src/Interpreters/InterpreterCreateQuery.cpp:1657: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000148f901b 10. /build/src/Interpreters/InterpreterCreateQuery.cpp:2352: DB::InterpreterCreateQuery::execute() @ 0x0000000014905a41 11. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88dc9 12. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 13. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 14. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 15. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 16. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 17. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 18. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 19. ? @ 0x00007fbc6213eac3 20. ? @ 0x00007fbc621d0850 2025.07.28 11:51:36.979036 [ 4581 ] {01bcade1-0e9a-4c4d-9a6c-e8ea44654396} 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.6.10636.altinitytest (altinity build)) (from [::1]:33012) (comment: 02981_nested_bad_types.sql) (query 45, line 54) (in query: create table test (x Tuple(String, Array(Map(String, Variant(LowCardinality(UInt64), String))))) engine=Memory;), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x000000000a06b56b 4. /build/src/Interpreters/parseColumnsListForTableFunction.cpp:67: DB::validateDataType(std::shared_ptr const&, DB::DataTypeValidationSettings const&)::$_0::operator()(DB::IDataType const&) const @ 0x0000000014ccea0b 5. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000013c0e9c9 6. /build/src/DataTypes/DataTypeTuple.cpp:413: DB::DataTypeTuple::forEachChild(std::function const&) const @ 0x0000000013c0b675 7. /build/src/Interpreters/parseColumnsListForTableFunction.cpp:173: DB::validateDataType(std::shared_ptr const&, DB::DataTypeValidationSettings const&) @ 0x0000000014ccde2d 8. /build/src/Interpreters/InterpreterCreateQuery.cpp:1037: DB::InterpreterCreateQuery::validateTableStructure(DB::ASTCreateQuery const&, DB::InterpreterCreateQuery::TableProperties const&) const @ 0x00000000148f3cdc 9. /build/src/Interpreters/InterpreterCreateQuery.cpp:1007: DB::InterpreterCreateQuery::getTablePropertiesAndNormalizeCreateQuery(DB::ASTCreateQuery&, DB::LoadingStrictnessLevel) const @ 0x00000000148f0ec3 10. /build/src/Interpreters/InterpreterCreateQuery.cpp:1657: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000148f901b 11. /build/src/Interpreters/InterpreterCreateQuery.cpp:2352: DB::InterpreterCreateQuery::execute() @ 0x0000000014905a41 12. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88dc9 13. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 14. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 15. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 16. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 17. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 18. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 19. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 20. ? @ 0x00007fbc6213eac3 21. ? @ 0x00007fbc621d0850 2025.07.28 11:51:36.983168 [ 4581 ] {} 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. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x000000000a06b56b 4. /build/src/Interpreters/parseColumnsListForTableFunction.cpp:67: DB::validateDataType(std::shared_ptr const&, DB::DataTypeValidationSettings const&)::$_0::operator()(DB::IDataType const&) const @ 0x0000000014ccea0b 5. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000013c0e9c9 6. /build/src/DataTypes/DataTypeTuple.cpp:413: DB::DataTypeTuple::forEachChild(std::function const&) const @ 0x0000000013c0b675 7. /build/src/Interpreters/parseColumnsListForTableFunction.cpp:173: DB::validateDataType(std::shared_ptr const&, DB::DataTypeValidationSettings const&) @ 0x0000000014ccde2d 8. /build/src/Interpreters/InterpreterCreateQuery.cpp:1037: DB::InterpreterCreateQuery::validateTableStructure(DB::ASTCreateQuery const&, DB::InterpreterCreateQuery::TableProperties const&) const @ 0x00000000148f3cdc 9. /build/src/Interpreters/InterpreterCreateQuery.cpp:1007: DB::InterpreterCreateQuery::getTablePropertiesAndNormalizeCreateQuery(DB::ASTCreateQuery&, DB::LoadingStrictnessLevel) const @ 0x00000000148f0ec3 10. /build/src/Interpreters/InterpreterCreateQuery.cpp:1657: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000148f901b 11. /build/src/Interpreters/InterpreterCreateQuery.cpp:2352: DB::InterpreterCreateQuery::execute() @ 0x0000000014905a41 12. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88dc9 13. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 14. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 15. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 16. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 17. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 18. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 19. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 20. ? @ 0x00007fbc6213eac3 21. ? @ 0x00007fbc621d0850 2025.07.28 11:51:37.103765 [ 4581 ] {03cab414-4890-4c39-b5d1-fd318c5bfa0d} executeQuery: Code: 44. DB::Exception: Cannot create column with type 'FixedString(1000000)' 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('42', 'Variant(UInt64, FixedString(1000000))'). (ILLEGAL_COLUMN) (version 25.3.6.10636.altinitytest (altinity build)) (from [::1]:33012) (comment: 02981_nested_bad_types.sql) (query 46, line 56) (in query: select '42'::Variant(UInt64, FixedString(1000000));), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, unsigned long const&) @ 0x000000000a3d916b 4. /build/src/Interpreters/parseColumnsListForTableFunction.cpp:92: DB::validateDataType(std::shared_ptr const&, DB::DataTypeValidationSettings const&)::$_0::operator()(DB::IDataType const&) const @ 0x0000000014cce8bf 5. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000013c0e9c9 6. /build/src/Interpreters/parseColumnsListForTableFunction.cpp:173: DB::validateDataType(std::shared_ptr const&, DB::DataTypeValidationSettings const&) @ 0x0000000014ccde2d 7. /build/src/Functions/CastOverloadResolver.cpp:128: DB::CastOverloadResolverImpl::getReturnTypeImpl(std::vector> const&) const @ 0x0000000012dcd4a5 8. /build/src/Functions/IFunction.cpp:645: DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x0000000012d96b0c 9. /build/src/Functions/IFunction.cpp:585: DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x0000000012d9665b 10. /build/src/Functions/IFunction.cpp:606: DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x0000000012d96edc 11. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3544: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000014033cc9 12. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3838: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000014019a9e 13. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3980: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000014018e31 14. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:4304: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000014042fa7 15. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5605: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000014013749 16. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000140127f9 17. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000014011fce 18. /build/src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000001406ce8a 19. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000014973b42 20. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000001497268d 21. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000014974d24 22. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001492924b 23. /build/src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88641 24. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 25. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 26. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 27. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 28. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 29. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 30. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 31. ? @ 0x00007fbc6213eac3 2025.07.28 11:51:37.109111 [ 4581 ] {} TCPHandler: Code: 44. DB::Exception: Cannot create column with type 'FixedString(1000000)' 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('42', 'Variant(UInt64, FixedString(1000000))'). (ILLEGAL_COLUMN), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, unsigned long const&) @ 0x000000000a3d916b 4. /build/src/Interpreters/parseColumnsListForTableFunction.cpp:92: DB::validateDataType(std::shared_ptr const&, DB::DataTypeValidationSettings const&)::$_0::operator()(DB::IDataType const&) const @ 0x0000000014cce8bf 5. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000013c0e9c9 6. /build/src/Interpreters/parseColumnsListForTableFunction.cpp:173: DB::validateDataType(std::shared_ptr const&, DB::DataTypeValidationSettings const&) @ 0x0000000014ccde2d 7. /build/src/Functions/CastOverloadResolver.cpp:128: DB::CastOverloadResolverImpl::getReturnTypeImpl(std::vector> const&) const @ 0x0000000012dcd4a5 8. /build/src/Functions/IFunction.cpp:645: DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x0000000012d96b0c 9. /build/src/Functions/IFunction.cpp:585: DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x0000000012d9665b 10. /build/src/Functions/IFunction.cpp:606: DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x0000000012d96edc 11. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3544: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000014033cc9 12. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3838: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000014019a9e 13. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3980: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000014018e31 14. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:4304: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000014042fa7 15. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5605: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000014013749 16. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000140127f9 17. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000014011fce 18. /build/src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000001406ce8a 19. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000014973b42 20. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000001497268d 21. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000014974d24 22. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001492924b 23. /build/src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88641 24. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 25. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 26. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 27. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 28. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 29. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 30. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 31. ? @ 0x00007fbc6213eac3 2025.07.28 11:51:37.275118 [ 4581 ] {b23dc54f-8cbe-4944-9e8f-8d53fc0030d5} executeQuery: Code: 44. DB::Exception: Cannot create column with type 'FixedString(1000000)' 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(('a', [map('b', '42')]), 'Tuple(String, Array(Map(String, Variant(UInt32, FixedString(1000000)))))'). (ILLEGAL_COLUMN) (version 25.3.6.10636.altinitytest (altinity build)) (from [::1]:33012) (comment: 02981_nested_bad_types.sql) (query 47, line 57) (in query: select tuple('a', [map('b', '42')])::Tuple(String, Array(Map(String, Variant(UInt32, FixedString(1000000)))));), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, unsigned long const&) @ 0x000000000a3d916b 4. /build/src/Interpreters/parseColumnsListForTableFunction.cpp:92: DB::validateDataType(std::shared_ptr const&, DB::DataTypeValidationSettings const&)::$_0::operator()(DB::IDataType const&) const @ 0x0000000014cce8bf 5. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000013c0e9c9 6. /build/src/DataTypes/DataTypeTuple.cpp:413: DB::DataTypeTuple::forEachChild(std::function const&) const @ 0x0000000013c0b675 7. /build/src/Interpreters/parseColumnsListForTableFunction.cpp:173: DB::validateDataType(std::shared_ptr const&, DB::DataTypeValidationSettings const&) @ 0x0000000014ccde2d 8. /build/src/Functions/CastOverloadResolver.cpp:128: DB::CastOverloadResolverImpl::getReturnTypeImpl(std::vector> const&) const @ 0x0000000012dcd4a5 9. /build/src/Functions/IFunction.cpp:645: DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x0000000012d96b0c 10. /build/src/Functions/IFunction.cpp:585: DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x0000000012d9665b 11. /build/src/Functions/IFunction.cpp:606: DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x0000000012d96edc 12. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3544: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000014033cc9 13. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3838: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000014019a9e 14. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3980: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000014018e31 15. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:4304: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000014042fa7 16. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5605: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000014013749 17. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000140127f9 18. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000014011fce 19. /build/src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000001406ce8a 20. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000014973b42 21. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000001497268d 22. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000014974d24 23. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001492924b 24. /build/src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88641 25. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 26. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 27. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 28. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 29. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 30. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 31. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 2025.07.28 11:51:37.280323 [ 4581 ] {} TCPHandler: Code: 44. DB::Exception: Cannot create column with type 'FixedString(1000000)' 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(('a', [map('b', '42')]), 'Tuple(String, Array(Map(String, Variant(UInt32, FixedString(1000000)))))'). (ILLEGAL_COLUMN), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, unsigned long const&) @ 0x000000000a3d916b 4. /build/src/Interpreters/parseColumnsListForTableFunction.cpp:92: DB::validateDataType(std::shared_ptr const&, DB::DataTypeValidationSettings const&)::$_0::operator()(DB::IDataType const&) const @ 0x0000000014cce8bf 5. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000013c0e9c9 6. /build/src/DataTypes/DataTypeTuple.cpp:413: DB::DataTypeTuple::forEachChild(std::function const&) const @ 0x0000000013c0b675 7. /build/src/Interpreters/parseColumnsListForTableFunction.cpp:173: DB::validateDataType(std::shared_ptr const&, DB::DataTypeValidationSettings const&) @ 0x0000000014ccde2d 8. /build/src/Functions/CastOverloadResolver.cpp:128: DB::CastOverloadResolverImpl::getReturnTypeImpl(std::vector> const&) const @ 0x0000000012dcd4a5 9. /build/src/Functions/IFunction.cpp:645: DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x0000000012d96b0c 10. /build/src/Functions/IFunction.cpp:585: DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x0000000012d9665b 11. /build/src/Functions/IFunction.cpp:606: DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x0000000012d96edc 12. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3544: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000014033cc9 13. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3838: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000014019a9e 14. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3980: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000014018e31 15. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:4304: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000014042fa7 16. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5605: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000014013749 17. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000140127f9 18. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000014011fce 19. /build/src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000001406ce8a 20. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000014973b42 21. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000001497268d 22. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000014974d24 23. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001492924b 24. /build/src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88641 25. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 26. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 27. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 28. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 29. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 30. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 31. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 2025.07.28 11:51:37.511212 [ 4581 ] {ef52092d-eead-43c6-9b34-5488f0b20243} executeQuery: Code: 44. DB::Exception: Cannot create column with type 'FixedString(1000000)' 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.6.10636.altinitytest (altinity build)) (from [::1]:33012) (comment: 02981_nested_bad_types.sql) (query 48, line 58) (in query: create table test (x Variant(UInt64, FixedString(1000000))) engine=Memory;), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, unsigned long const&) @ 0x000000000a3d916b 4. /build/src/Interpreters/parseColumnsListForTableFunction.cpp:92: DB::validateDataType(std::shared_ptr const&, DB::DataTypeValidationSettings const&)::$_0::operator()(DB::IDataType const&) const @ 0x0000000014cce8bf 5. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000013c0e9c9 6. /build/src/Interpreters/parseColumnsListForTableFunction.cpp:173: DB::validateDataType(std::shared_ptr const&, DB::DataTypeValidationSettings const&) @ 0x0000000014ccde2d 7. /build/src/Interpreters/InterpreterCreateQuery.cpp:1037: DB::InterpreterCreateQuery::validateTableStructure(DB::ASTCreateQuery const&, DB::InterpreterCreateQuery::TableProperties const&) const @ 0x00000000148f3cdc 8. /build/src/Interpreters/InterpreterCreateQuery.cpp:1007: DB::InterpreterCreateQuery::getTablePropertiesAndNormalizeCreateQuery(DB::ASTCreateQuery&, DB::LoadingStrictnessLevel) const @ 0x00000000148f0ec3 9. /build/src/Interpreters/InterpreterCreateQuery.cpp:1657: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000148f901b 10. /build/src/Interpreters/InterpreterCreateQuery.cpp:2352: DB::InterpreterCreateQuery::execute() @ 0x0000000014905a41 11. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88dc9 12. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 13. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 14. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 15. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 16. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 17. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 18. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 19. ? @ 0x00007fbc6213eac3 20. ? @ 0x00007fbc621d0850 2025.07.28 11:51:37.524545 [ 4581 ] {} TCPHandler: Code: 44. DB::Exception: Cannot create column with type 'FixedString(1000000)' 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. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, unsigned long const&) @ 0x000000000a3d916b 4. /build/src/Interpreters/parseColumnsListForTableFunction.cpp:92: DB::validateDataType(std::shared_ptr const&, DB::DataTypeValidationSettings const&)::$_0::operator()(DB::IDataType const&) const @ 0x0000000014cce8bf 5. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000013c0e9c9 6. /build/src/Interpreters/parseColumnsListForTableFunction.cpp:173: DB::validateDataType(std::shared_ptr const&, DB::DataTypeValidationSettings const&) @ 0x0000000014ccde2d 7. /build/src/Interpreters/InterpreterCreateQuery.cpp:1037: DB::InterpreterCreateQuery::validateTableStructure(DB::ASTCreateQuery const&, DB::InterpreterCreateQuery::TableProperties const&) const @ 0x00000000148f3cdc 8. /build/src/Interpreters/InterpreterCreateQuery.cpp:1007: DB::InterpreterCreateQuery::getTablePropertiesAndNormalizeCreateQuery(DB::ASTCreateQuery&, DB::LoadingStrictnessLevel) const @ 0x00000000148f0ec3 9. /build/src/Interpreters/InterpreterCreateQuery.cpp:1657: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000148f901b 10. /build/src/Interpreters/InterpreterCreateQuery.cpp:2352: DB::InterpreterCreateQuery::execute() @ 0x0000000014905a41 11. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88dc9 12. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 13. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 14. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 15. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 16. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 17. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 18. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 19. ? @ 0x00007fbc6213eac3 20. ? @ 0x00007fbc621d0850 2025.07.28 11:51:37.557292 [ 4581 ] {f3eafb35-038f-4f99-949a-e9c0c233a686} executeQuery: Code: 44. DB::Exception: Cannot create column with type 'FixedString(1000000)' 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.6.10636.altinitytest (altinity build)) (from [::1]:33012) (comment: 02981_nested_bad_types.sql) (query 49, line 59) (in query: create table test (x Tuple(String, Array(Map(String, FixedString(1000000))))) engine=Memory;), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, unsigned long const&) @ 0x000000000a3d916b 4. /build/src/Interpreters/parseColumnsListForTableFunction.cpp:92: DB::validateDataType(std::shared_ptr const&, DB::DataTypeValidationSettings const&)::$_0::operator()(DB::IDataType const&) const @ 0x0000000014cce8bf 5. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000013bf3d4b 6. /build/src/DataTypes/DataTypeTuple.cpp:413: DB::DataTypeTuple::forEachChild(std::function const&) const @ 0x0000000013c0b675 7. /build/src/Interpreters/parseColumnsListForTableFunction.cpp:173: DB::validateDataType(std::shared_ptr const&, DB::DataTypeValidationSettings const&) @ 0x0000000014ccde2d 8. /build/src/Interpreters/InterpreterCreateQuery.cpp:1037: DB::InterpreterCreateQuery::validateTableStructure(DB::ASTCreateQuery const&, DB::InterpreterCreateQuery::TableProperties const&) const @ 0x00000000148f3cdc 9. /build/src/Interpreters/InterpreterCreateQuery.cpp:1007: DB::InterpreterCreateQuery::getTablePropertiesAndNormalizeCreateQuery(DB::ASTCreateQuery&, DB::LoadingStrictnessLevel) const @ 0x00000000148f0ec3 10. /build/src/Interpreters/InterpreterCreateQuery.cpp:1657: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000148f901b 11. /build/src/Interpreters/InterpreterCreateQuery.cpp:2352: DB::InterpreterCreateQuery::execute() @ 0x0000000014905a41 12. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88dc9 13. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 14. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 15. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 16. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 17. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 18. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 19. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 20. ? @ 0x00007fbc6213eac3 21. ? @ 0x00007fbc621d0850 2025.07.28 11:51:37.565670 [ 4581 ] {} TCPHandler: Code: 44. DB::Exception: Cannot create column with type 'FixedString(1000000)' 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. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, unsigned long const&) @ 0x000000000a3d916b 4. /build/src/Interpreters/parseColumnsListForTableFunction.cpp:92: DB::validateDataType(std::shared_ptr const&, DB::DataTypeValidationSettings const&)::$_0::operator()(DB::IDataType const&) const @ 0x0000000014cce8bf 5. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000013bf3d4b 6. /build/src/DataTypes/DataTypeTuple.cpp:413: DB::DataTypeTuple::forEachChild(std::function const&) const @ 0x0000000013c0b675 7. /build/src/Interpreters/parseColumnsListForTableFunction.cpp:173: DB::validateDataType(std::shared_ptr const&, DB::DataTypeValidationSettings const&) @ 0x0000000014ccde2d 8. /build/src/Interpreters/InterpreterCreateQuery.cpp:1037: DB::InterpreterCreateQuery::validateTableStructure(DB::ASTCreateQuery const&, DB::InterpreterCreateQuery::TableProperties const&) const @ 0x00000000148f3cdc 9. /build/src/Interpreters/InterpreterCreateQuery.cpp:1007: DB::InterpreterCreateQuery::getTablePropertiesAndNormalizeCreateQuery(DB::ASTCreateQuery&, DB::LoadingStrictnessLevel) const @ 0x00000000148f0ec3 10. /build/src/Interpreters/InterpreterCreateQuery.cpp:1657: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000148f901b 11. /build/src/Interpreters/InterpreterCreateQuery.cpp:2352: DB::InterpreterCreateQuery::execute() @ 0x0000000014905a41 12. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88dc9 13. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 14. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 15. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 16. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 17. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 18. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 19. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 20. ? @ 0x00007fbc6213eac3 21. ? @ 0x00007fbc621d0850 2025.07.28 11:51:41.975518 [ 15481 ] {466f014b-75cc-4734-bee5-e82ee27459bb} 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.6.10636.altinitytest (altinity build)) (from [::1]:33056) (comment: 02993_lazy_index_loading.sql) (query 6, line 8) (in query: DETACH TABLE test;), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000000a074fcb 4. /build/src/Databases/DatabaseReplicated.cpp:1108: DB::DatabaseReplicated::checkQueryValid(std::shared_ptr const&, std::shared_ptr) const @ 0x0000000013d9ef48 5. /build/src/Databases/DatabaseReplicated.cpp:1130: DB::DatabaseReplicated::tryEnqueueReplicatedDDL(std::shared_ptr const&, std::shared_ptr, DB::QueryFlags) @ 0x0000000013d9f10b 6. /build/src/Interpreters/InterpreterDropQuery.cpp:226: DB::InterpreterDropQuery::executeToTableImpl(std::shared_ptr const&, DB::ASTDropQuery&, std::shared_ptr&, StrongTypedef, DB::UUIDTag>&) @ 0x0000000014914ed7 7. /build/src/Interpreters/InterpreterDropQuery.cpp:118: DB::InterpreterDropQuery::executeToTable(DB::ASTDropQuery&) @ 0x00000000149137b4 8. /build/src/Interpreters/InterpreterDropQuery.cpp:91: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000014912f07 9. /build/src/Interpreters/InterpreterDropQuery.cpp:72: DB::InterpreterDropQuery::execute() @ 0x0000000014912b65 10. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88dc9 11. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 12. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 13. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 14. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 15. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 16. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 17. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 18. ? @ 0x00007fbc6213eac3 19. ? @ 0x00007fbc621d0850 2025.07.28 11:51:42.082368 [ 15481 ] {} 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. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000000a074fcb 4. /build/src/Databases/DatabaseReplicated.cpp:1108: DB::DatabaseReplicated::checkQueryValid(std::shared_ptr const&, std::shared_ptr) const @ 0x0000000013d9ef48 5. /build/src/Databases/DatabaseReplicated.cpp:1130: DB::DatabaseReplicated::tryEnqueueReplicatedDDL(std::shared_ptr const&, std::shared_ptr, DB::QueryFlags) @ 0x0000000013d9f10b 6. /build/src/Interpreters/InterpreterDropQuery.cpp:226: DB::InterpreterDropQuery::executeToTableImpl(std::shared_ptr const&, DB::ASTDropQuery&, std::shared_ptr&, StrongTypedef, DB::UUIDTag>&) @ 0x0000000014914ed7 7. /build/src/Interpreters/InterpreterDropQuery.cpp:118: DB::InterpreterDropQuery::executeToTable(DB::ASTDropQuery&) @ 0x00000000149137b4 8. /build/src/Interpreters/InterpreterDropQuery.cpp:91: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000014912f07 9. /build/src/Interpreters/InterpreterDropQuery.cpp:72: DB::InterpreterDropQuery::execute() @ 0x0000000014912b65 10. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88dc9 11. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 12. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 13. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 14. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 15. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 16. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 17. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 18. ? @ 0x00007fbc6213eac3 19. ? @ 0x00007fbc621d0850 2025.07.28 11:51:42.832206 [ 17232 ] {e2626722-f778-42e3-a0ad-dce49059da5f} executeQuery: Code: 43. DB::Exception: Illegal types of arguments: Map(String, UInt8), UInt8 for function arrayElement. (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.6.10636.altinitytest (altinity build)) (from [::1]:54944) (comment: 02407_array_element_from_map_wrong_type.sql) (query 1, line 1) (in query: select m[0], materialize(map('key', 42)) as m;), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&) @ 0x000000000a10182b 4. /build/src/Functions/array/arrayElement.cpp:1959: DB::(anonymous namespace)::FunctionArrayElement<(DB::(anonymous namespace)::ArrayElementExceptionMode)0>::executeMap(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000f2baa16 5. /build/src/Functions/array/arrayElement.cpp:2026: DB::(anonymous namespace)::FunctionArrayElement<(DB::(anonymous namespace)::ArrayElementExceptionMode)0>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000f2b6ea5 6. /build/src/Functions/IFunction.h:437: DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000a069f2a 7. /build/src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000012d9965a 8. /build/src/Functions/IFunction.cpp:351: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d93b02 9. /build/src/Functions/IFunction.cpp:420: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d95059 10. /build/src/Functions/IFunction.cpp:498: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d95c72 11. /build/src/Interpreters/ActionsDAG.cpp:812: DB::ActionsDAG::evaluatePartialResult(std::unordered_map, std::equal_to, std::allocator>>&, std::vector> const&, unsigned long, bool) @ 0x0000000013fa38cc 12. /build/src/Interpreters/ActionsDAG.cpp:892: DB::ActionsDAG::updateHeader(DB::Block const&) const @ 0x0000000013fa29a8 13. /build/src/Processors/Transforms/ExpressionTransform.cpp:10: DB::ExpressionTransform::transformHeader(DB::Block const&, DB::ActionsDAG const&) @ 0x0000000016c0afd2 14. /build/src/Processors/QueryPlan/ExpressionStep.cpp:38: DB::ExpressionStep::ExpressionStep(DB::Block const&, DB::ActionsDAG) @ 0x0000000016db8ad1 15. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107](DB::Block const&, DB::ActionsDAG&&) @ 0x00000000131ee01a 16. /build/src/Planner/Planner.cpp:392: DB::(anonymous namespace)::addExpressionStep(DB::QueryPlan&, std::shared_ptr&, String const&, std::unordered_set, std::hash>, std::equal_to>, std::allocator>>&) @ 0x000000001498191d 17. /build/src/Planner/Planner.cpp:1648: DB::Planner::buildPlanForQueryNode() @ 0x000000001497b7aa 18. /build/src/Planner/Planner.cpp:1308: DB::Planner::buildQueryPlanIfNeeded() @ 0x000000001497685c 19. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:255: DB::InterpreterSelectQueryAnalyzer::getQueryPlan() @ 0x000000001497476d 20. /build/src/Interpreters/executeQuery.cpp:1405: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88806 21. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 22. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 23. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 24. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 25. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 26. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 27. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 28. ? @ 0x00007fbc6213eac3 29. ? @ 0x00007fbc621d0850 2025.07.28 11:51:42.848129 [ 17232 ] {} TCPHandler: Code: 43. DB::Exception: Illegal types of arguments: Map(String, UInt8), UInt8 for function arrayElement. (ILLEGAL_TYPE_OF_ARGUMENT), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&) @ 0x000000000a10182b 4. /build/src/Functions/array/arrayElement.cpp:1959: DB::(anonymous namespace)::FunctionArrayElement<(DB::(anonymous namespace)::ArrayElementExceptionMode)0>::executeMap(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000f2baa16 5. /build/src/Functions/array/arrayElement.cpp:2026: DB::(anonymous namespace)::FunctionArrayElement<(DB::(anonymous namespace)::ArrayElementExceptionMode)0>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000f2b6ea5 6. /build/src/Functions/IFunction.h:437: DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000a069f2a 7. /build/src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000012d9965a 8. /build/src/Functions/IFunction.cpp:351: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d93b02 9. /build/src/Functions/IFunction.cpp:420: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d95059 10. /build/src/Functions/IFunction.cpp:498: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d95c72 11. /build/src/Interpreters/ActionsDAG.cpp:812: DB::ActionsDAG::evaluatePartialResult(std::unordered_map, std::equal_to, std::allocator>>&, std::vector> const&, unsigned long, bool) @ 0x0000000013fa38cc 12. /build/src/Interpreters/ActionsDAG.cpp:892: DB::ActionsDAG::updateHeader(DB::Block const&) const @ 0x0000000013fa29a8 13. /build/src/Processors/Transforms/ExpressionTransform.cpp:10: DB::ExpressionTransform::transformHeader(DB::Block const&, DB::ActionsDAG const&) @ 0x0000000016c0afd2 14. /build/src/Processors/QueryPlan/ExpressionStep.cpp:38: DB::ExpressionStep::ExpressionStep(DB::Block const&, DB::ActionsDAG) @ 0x0000000016db8ad1 15. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107](DB::Block const&, DB::ActionsDAG&&) @ 0x00000000131ee01a 16. /build/src/Planner/Planner.cpp:392: DB::(anonymous namespace)::addExpressionStep(DB::QueryPlan&, std::shared_ptr&, String const&, std::unordered_set, std::hash>, std::equal_to>, std::allocator>>&) @ 0x000000001498191d 17. /build/src/Planner/Planner.cpp:1648: DB::Planner::buildPlanForQueryNode() @ 0x000000001497b7aa 18. /build/src/Planner/Planner.cpp:1308: DB::Planner::buildQueryPlanIfNeeded() @ 0x000000001497685c 19. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:255: DB::InterpreterSelectQueryAnalyzer::getQueryPlan() @ 0x000000001497476d 20. /build/src/Interpreters/executeQuery.cpp:1405: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88806 21. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 22. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 23. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 24. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 25. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 26. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 27. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 28. ? @ 0x00007fbc6213eac3 29. ? @ 0x00007fbc621d0850 2025.07.28 11:51:43.998441 [ 3936 ] {} MergeTreeBackgroundExecutor: Exception while executing background task {2956b435-396d-41f9-85d2-aa65f8c4eb09::all_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. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, char const*&&, char const*&&) @ 0x000000000fc1a8eb 4. /build/src/Common/MemoryTracker.cpp:196: MemoryTracker::injectFault() const @ 0x000000000fc18390 5. /build/src/Storages/MergeTree/MergePlainMergeTreeTask.cpp:153: DB::MergePlainMergeTreeTask::finish() @ 0x000000001666f399 6. /build/src/Storages/MergeTree/MergePlainMergeTreeTask.cpp:72: DB::MergePlainMergeTreeTask::executeStep() @ 0x000000001666e852 7. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000162fc850 8. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x00000000162fd193 9. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc6653 10. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000000fccc4c3 11. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc3d92 12. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fcca080 13. ? @ 0x00007fbc6213eac3 14. ? @ 0x00007fbc621d0850 (version 25.3.6.10636.altinitytest (altinity build)) 2025.07.28 11:51:45.279900 [ 7630 ] {98f24e4f-6cb5-461d-816f-199dba15169c} executeQuery: Code: 86. DB::HTTPException: Received error from remote server /test%2Fa.tsv. HTTP status code: 403 'Forbidden', body length: 301 bytes, body: ' AccessDeniedAccess Denied.test%2Fa.tsv/test/a.tsv1856617F8003EB187dc7eb22d3288ec80374614e9088e31d3668a6922ead55932dd2a8e56373820f': The table structure cannot be extracted from a TSV format file. You can specify the structure manually. (RECEIVED_ERROR_FROM_REMOTE_IO_SERVER) (version 25.3.6.10636.altinitytest (altinity build)) (from [::1]:55684) (comment: 02833_url_without_path_encoding.sh) (query 1, line 1) (in query: select count() from url('http://localhost:11111/test%2Fa.tsv') settings enable_url_encoding=0), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.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 const&, int&&, String const&, unsigned long&&, String const&) @ 0x000000000feda8d9 4. /build/src/IO/HTTPCommon.cpp:104: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x000000000feda6e2 5. /build/src/IO/HTTPCommon.cpp:93: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x000000000feda537 6. /build/src/IO/ReadWriteBufferFromHTTP.cpp:277: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x000000001184a4c4 7. /build/src/IO/ReadWriteBufferFromHTTP.cpp:285: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x000000001184a615 8. /build/src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x000000001184ae59 9. /build/src/IO/ReadWriteBufferFromHTTP.cpp:472: void std::__function::__policy_invoker::__call_impl[abi:se190107]>(std::__function::__policy_storage const*) @ 0x000000001184cedd 10. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001184858b 11. /build/src/IO/ReadWriteBufferFromHTTP.cpp:465: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x000000001184bf0b 12. /build/src/IO/ReadBuffer.h:60: DB::ReadBuffer::next() @ 0x000000000a148c7b 13. /build/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) @ 0x0000000011849fb2 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]>&)>&, 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&) @ 0x0000000011841980 15. /build/src/IO/ReadWriteBufferFromHTTP.h:248: DB::StorageURLSource::getFirstAvailableURIAndReadBuffer(std::__wrap_iter&, std::__wrap_iter const&, std::shared_ptr, std::vector, std::allocator>> const&, String const&, std::function>&)>, DB::ConnectionTimeouts const&, Poco::Net::HTTPBasicCredentials&, std::vector> const&, bool, bool) @ 0x0000000016020687 16. /build/src/Storages/StorageURL.cpp:858: DB::(anonymous namespace)::ReadBufferIterator::next() @ 0x00000000160281c4 17. /build/src/Formats/ReadSchemaUtils.cpp:152: DB::readSchemaFromFormatImpl(std::optional, std::optional const&, DB::IReadBufferIterator&, std::shared_ptr const&) @ 0x00000000169766c7 18. /build/src/Formats/ReadSchemaUtils.cpp:548: DB::readSchemaFromFormat(String const&, std::optional const&, DB::IReadBufferIterator&, std::shared_ptr const&) @ 0x000000001697a742 19. /build/src/Storages/StorageURL.cpp:1021: DB::IStorageURLBase::getTableStructureAndFormatFromDataImpl(std::optional, String const&, DB::CompressionMethod, std::vector> const&, std::optional const&, std::shared_ptr const&) @ 0x0000000016022248 20. /build/src/Storages/StorageURL.cpp:1033: DB::IStorageURLBase::getTableStructureFromData(String const&, String const&, DB::CompressionMethod, std::vector> const&, std::optional const&, std::shared_ptr const&) @ 0x000000001601ddbc 21. /build/src/TableFunctions/TableFunctionURL.cpp:149: DB::TableFunctionURL::getActualTableStructure(std::shared_ptr, bool) const @ 0x0000000011829768 22. /build/src/TableFunctions/TableFunctionURL.cpp:115: DB::TableFunctionURL::getStorage(String const&, String const&, DB::ColumnsDescription const&, std::shared_ptr, String const&, String const&, bool) const @ 0x0000000011828f6d 23. /build/src/TableFunctions/ITableFunctionFileLike.cpp:96: DB::ITableFunctionFileLike::executeImpl(std::shared_ptr const&, std::shared_ptr, String const&, DB::ColumnsDescription, bool) const @ 0x000000001182689c 24. /build/src/TableFunctions/ITableFunction.cpp:36: DB::ITableFunction::execute(std::shared_ptr const&, std::shared_ptr, String const&, DB::ColumnsDescription, bool, bool) const @ 0x00000000131e9fc3 25. /build/src/Interpreters/Context.cpp:2501: DB::Context::executeTableFunction(std::shared_ptr const&, std::shared_ptr const&) @ 0x00000000144345b2 26. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:4975: DB::QueryAnalyzer::resolveTableFunction(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&, bool) @ 0x000000001401e9f9 27. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5342: DB::QueryAnalyzer::resolveQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&) @ 0x00000000140452bf 28. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5597: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000140136f0 29. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000140127f9 30. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000014011fce 31. /build/src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000001406ce8a 2025.07.28 11:51:45.311602 [ 7630 ] {} TCPHandler: Code: 86. DB::HTTPException: Received error from remote server /test%2Fa.tsv. HTTP status code: 403 'Forbidden', body length: 301 bytes, body: ' AccessDeniedAccess Denied.test%2Fa.tsv/test/a.tsv1856617F8003EB187dc7eb22d3288ec80374614e9088e31d3668a6922ead55932dd2a8e56373820f': The table structure cannot be extracted from a TSV format file. You can specify the structure manually. (RECEIVED_ERROR_FROM_REMOTE_IO_SERVER), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.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 const&, int&&, String const&, unsigned long&&, String const&) @ 0x000000000feda8d9 4. /build/src/IO/HTTPCommon.cpp:104: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x000000000feda6e2 5. /build/src/IO/HTTPCommon.cpp:93: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x000000000feda537 6. /build/src/IO/ReadWriteBufferFromHTTP.cpp:277: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x000000001184a4c4 7. /build/src/IO/ReadWriteBufferFromHTTP.cpp:285: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x000000001184a615 8. /build/src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x000000001184ae59 9. /build/src/IO/ReadWriteBufferFromHTTP.cpp:472: void std::__function::__policy_invoker::__call_impl[abi:se190107]>(std::__function::__policy_storage const*) @ 0x000000001184cedd 10. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001184858b 11. /build/src/IO/ReadWriteBufferFromHTTP.cpp:465: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x000000001184bf0b 12. /build/src/IO/ReadBuffer.h:60: DB::ReadBuffer::next() @ 0x000000000a148c7b 13. /build/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) @ 0x0000000011849fb2 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]>&)>&, 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&) @ 0x0000000011841980 15. /build/src/IO/ReadWriteBufferFromHTTP.h:248: DB::StorageURLSource::getFirstAvailableURIAndReadBuffer(std::__wrap_iter&, std::__wrap_iter const&, std::shared_ptr, std::vector, std::allocator>> const&, String const&, std::function>&)>, DB::ConnectionTimeouts const&, Poco::Net::HTTPBasicCredentials&, std::vector> const&, bool, bool) @ 0x0000000016020687 16. /build/src/Storages/StorageURL.cpp:858: DB::(anonymous namespace)::ReadBufferIterator::next() @ 0x00000000160281c4 17. /build/src/Formats/ReadSchemaUtils.cpp:152: DB::readSchemaFromFormatImpl(std::optional, std::optional const&, DB::IReadBufferIterator&, std::shared_ptr const&) @ 0x00000000169766c7 18. /build/src/Formats/ReadSchemaUtils.cpp:548: DB::readSchemaFromFormat(String const&, std::optional const&, DB::IReadBufferIterator&, std::shared_ptr const&) @ 0x000000001697a742 19. /build/src/Storages/StorageURL.cpp:1021: DB::IStorageURLBase::getTableStructureAndFormatFromDataImpl(std::optional, String const&, DB::CompressionMethod, std::vector> const&, std::optional const&, std::shared_ptr const&) @ 0x0000000016022248 20. /build/src/Storages/StorageURL.cpp:1033: DB::IStorageURLBase::getTableStructureFromData(String const&, String const&, DB::CompressionMethod, std::vector> const&, std::optional const&, std::shared_ptr const&) @ 0x000000001601ddbc 21. /build/src/TableFunctions/TableFunctionURL.cpp:149: DB::TableFunctionURL::getActualTableStructure(std::shared_ptr, bool) const @ 0x0000000011829768 22. /build/src/TableFunctions/TableFunctionURL.cpp:115: DB::TableFunctionURL::getStorage(String const&, String const&, DB::ColumnsDescription const&, std::shared_ptr, String const&, String const&, bool) const @ 0x0000000011828f6d 23. /build/src/TableFunctions/ITableFunctionFileLike.cpp:96: DB::ITableFunctionFileLike::executeImpl(std::shared_ptr const&, std::shared_ptr, String const&, DB::ColumnsDescription, bool) const @ 0x000000001182689c 24. /build/src/TableFunctions/ITableFunction.cpp:36: DB::ITableFunction::execute(std::shared_ptr const&, std::shared_ptr, String const&, DB::ColumnsDescription, bool, bool) const @ 0x00000000131e9fc3 25. /build/src/Interpreters/Context.cpp:2501: DB::Context::executeTableFunction(std::shared_ptr const&, std::shared_ptr const&) @ 0x00000000144345b2 26. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:4975: DB::QueryAnalyzer::resolveTableFunction(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&, bool) @ 0x000000001401e9f9 27. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5342: DB::QueryAnalyzer::resolveQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&) @ 0x00000000140452bf 28. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5597: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000140136f0 29. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000140127f9 30. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000014011fce 31. /build/src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000001406ce8a 2025.07.28 11:51:45.319298 [ 17203 ] {4a480c5e-d241-4b65-a231-7ab10fd9b6c7} executeQuery: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=818, jobs=792). (CANNOT_SCHEDULE_TASK) (version 25.3.6.10636.altinitytest (altinity build)) (from [::1]:55712) (comment: 03238_create_or_replace_view_atomically_with_replicated_engine.sh) (query 1, line 1) (in query: SELECT * FROM test_9_db.test_view), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000fccaeeb 4. /build/src/Common/ThreadPool.cpp:275: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000fccacb3 5. /build/src/Common/ThreadPool.cpp:323: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fcc4ffc 6. /build/src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000000fcc584d 7. /build/src/Common/ThreadPool.h:279: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x00000000169bf193 8. /build/src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x00000000169bf518 9. /build/src/Server/TCPHandler.cpp:1237: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x00000000168f1525 10. /build/src/Server/TCPHandler.cpp:678: DB::TCPHandler::runImpl() @ 0x00000000168e68e5 11. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 12. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 13. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 14. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 15. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 16. ? @ 0x00007fbc6213eac3 17. ? @ 0x00007fbc621d0850 2025.07.28 11:51:45.331806 [ 17203 ] {} TCPHandler: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=818, jobs=792). (CANNOT_SCHEDULE_TASK), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000fccaeeb 4. /build/src/Common/ThreadPool.cpp:275: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000fccacb3 5. /build/src/Common/ThreadPool.cpp:323: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fcc4ffc 6. /build/src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000000fcc584d 7. /build/src/Common/ThreadPool.h:279: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x00000000169bf193 8. /build/src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x00000000169bf518 9. /build/src/Server/TCPHandler.cpp:1237: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x00000000168f1525 10. /build/src/Server/TCPHandler.cpp:678: DB::TCPHandler::runImpl() @ 0x00000000168e68e5 11. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 12. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 13. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 14. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 15. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 16. ? @ 0x00007fbc6213eac3 17. ? @ 0x00007fbc621d0850 2025.07.28 11:51:45.879601 [ 17232 ] {f831bfd2-36bd-4e40-af0f-e74880dc9f19} executeQuery: Code: 48. DB::Exception: Truncate is not supported by storage View. (NOT_IMPLEMENTED) (version 25.3.6.10636.altinitytest (altinity build)) (from [::1]:55798) (comment: 02539_settings_alias.sh) (query 4, line 5) (in query: DROP VIEW 02539_settings_alias_view;), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x000000000a06b56b 4. /build/src/Storages/IStorage.cpp:171: DB::IStorage::truncate(std::shared_ptr const&, std::shared_ptr const&, std::shared_ptr, DB::TableExclusiveLockHolder&) @ 0x0000000015d1ec7a 5. /build/src/Interpreters/InterpreterDropQuery.cpp:282: DB::InterpreterDropQuery::executeToTableImpl(std::shared_ptr const&, DB::ASTDropQuery&, std::shared_ptr&, StrongTypedef, DB::UUIDTag>&) @ 0x0000000014915304 6. /build/src/Interpreters/InterpreterDropQuery.cpp:118: DB::InterpreterDropQuery::executeToTable(DB::ASTDropQuery&) @ 0x00000000149137b4 7. /build/src/Interpreters/InterpreterDropQuery.cpp:91: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000014912f07 8. /build/src/Interpreters/InterpreterDropQuery.cpp:72: DB::InterpreterDropQuery::execute() @ 0x0000000014912b65 9. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88dc9 10. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 11. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 12. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 13. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 14. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 16. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 17. ? @ 0x00007fbc6213eac3 18. ? @ 0x00007fbc621d0850 2025.07.28 11:51:45.887959 [ 17232 ] {} 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. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x000000000a06b56b 4. /build/src/Storages/IStorage.cpp:171: DB::IStorage::truncate(std::shared_ptr const&, std::shared_ptr const&, std::shared_ptr, DB::TableExclusiveLockHolder&) @ 0x0000000015d1ec7a 5. /build/src/Interpreters/InterpreterDropQuery.cpp:282: DB::InterpreterDropQuery::executeToTableImpl(std::shared_ptr const&, DB::ASTDropQuery&, std::shared_ptr&, StrongTypedef, DB::UUIDTag>&) @ 0x0000000014915304 6. /build/src/Interpreters/InterpreterDropQuery.cpp:118: DB::InterpreterDropQuery::executeToTable(DB::ASTDropQuery&) @ 0x00000000149137b4 7. /build/src/Interpreters/InterpreterDropQuery.cpp:91: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000014912f07 8. /build/src/Interpreters/InterpreterDropQuery.cpp:72: DB::InterpreterDropQuery::execute() @ 0x0000000014912b65 9. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88dc9 10. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 11. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 12. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 13. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 14. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 16. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 17. ? @ 0x00007fbc6213eac3 18. ? @ 0x00007fbc621d0850 2025.07.28 11:51:46.241581 [ 17210 ] {f92768e2-b549-49fa-ac50-93555012b9e9} 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 connecting to socket (128.1.2.3:9000, connection timeout 1 ms) Code: 209. DB::NetException: Timeout: connect timed out: 128.1.2.3:9000 (128.1.2.3:9000, connection timeout 1 ms). (SOCKET_TIMEOUT) (version 25.3.6.10636.altinitytest (altinity build)) Code: 209. DB::NetException: Timeout: connect timed out: 128.1.2.3:9000 (128.1.2.3:9000, connection timeout 1 ms). (SOCKET_TIMEOUT) (version 25.3.6.10636.altinitytest (altinity build)) Code: 209. DB::NetException: Timeout: connect timed out: 128.1.2.3:9000 (128.1.2.3:9000, connection timeout 1 ms). (SOCKET_TIMEOUT) (version 25.3.6.10636.altinitytest (altinity build)) Code: 209. DB::NetException: Timeout: connect timed out: 128.1.2.3:9000 (128.1.2.3:9000, connection timeout 1 ms). (SOCKET_TIMEOUT) (version 25.3.6.10636.altinitytest (altinity build)) Code: 209. DB::NetException: Timeout: connect timed out: 128.1.2.3:9000 (128.1.2.3:9000, connection timeout 1 ms). (SOCKET_TIMEOUT) (version 25.3.6.10636.altinitytest (altinity build)) Code: 209. DB::NetException: Timeout: connect timed out: 128.1.2.3:9000 (128.1.2.3:9000, connection timeout 1 ms). (SOCKET_TIMEOUT) (version 25.3.6.10636.altinitytest (altinity build)) Code: 209. DB::NetException: Timeout: connect timed out: 128.1.2.3:9000 (128.1.2.3:9000, connection timeout 1 ms). (SOCKET_TIMEOUT) (version 25.3.6.10636.altinitytest (altinity build)) Code: 209. DB::NetException: Timeout: connect timed out: 128.1.2.3:9000 (128.1.2.3:9000, connection timeout 1 ms). (SOCKET_TIMEOUT) (version 25.3.6.10636.altinitytest (altinity build)) Code: 209. DB::NetException: Timeout: connect timed out: 128.1.2.3:9000 (128.1.2.3:9000, connection timeout 1 ms). (SOCKET_TIMEOUT) (version 25.3.6.10636.altinitytest (altinity build)) . (ALL_CONNECTION_TRIES_FAILED) (version 25.3.6.10636.altinitytest (altinity build)) . (NO_REMOTE_SHARD_AVAILABLE) (version 25.3.6.10636.altinitytest (altinity build)) (from [::1]:55900) (comment: 01361_fover_remote_num_tries.sh) (query 1, line 1) (in query: SELECT hostName() FROM remote('128.1.2.3', default.tmp)), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::NetException::NetException(int, FormatStringHelperImpl::type>, String&) @ 0x0000000016056ce9 3. /build/src/Storages/getStructureOfRemoteTable.cpp:177: DB::getStructureOfRemoteTable(DB::Cluster const&, DB::StorageID const&, std::shared_ptr, std::shared_ptr const&) @ 0x00000000160552a4 4. /build/src/TableFunctions/TableFunctionRemote.cpp:337: DB::TableFunctionRemote::getActualTableStructure(std::shared_ptr, bool) const @ 0x0000000011805ecb 5. /build/src/TableFunctions/TableFunctionRemote.cpp:309: DB::TableFunctionRemote::executeImpl(std::shared_ptr const&, std::shared_ptr, String const&, DB::ColumnsDescription, bool) const @ 0x00000000118056e0 6. /build/src/TableFunctions/ITableFunction.cpp:36: DB::ITableFunction::execute(std::shared_ptr const&, std::shared_ptr, String const&, DB::ColumnsDescription, bool, bool) const @ 0x00000000131e9fc3 7. /build/src/Interpreters/Context.cpp:2501: DB::Context::executeTableFunction(std::shared_ptr const&, std::shared_ptr const&) @ 0x00000000144345b2 8. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:4975: DB::QueryAnalyzer::resolveTableFunction(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&, bool) @ 0x000000001401e9f9 9. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5342: DB::QueryAnalyzer::resolveQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&) @ 0x00000000140452bf 10. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5597: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000140136f0 11. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000140127f9 12. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000014011fce 13. /build/src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000001406ce8a 14. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000014973b42 15. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000001497268d 16. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000014974d24 17. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001492924b 18. /build/src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88641 19. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 20. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 21. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 22. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 23. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 24. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 25. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 26. ? @ 0x00007fbc6213eac3 27. ? @ 0x00007fbc621d0850 2025.07.28 11:51:46.279136 [ 17210 ] {} 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 connecting to socket (128.1.2.3:9000, connection timeout 1 ms) Code: 209. DB::NetException: Timeout: connect timed out: 128.1.2.3:9000 (128.1.2.3:9000, connection timeout 1 ms). (SOCKET_TIMEOUT) (version 25.3.6.10636.altinitytest (altinity build)) Code: 209. DB::NetException: Timeout: connect timed out: 128.1.2.3:9000 (128.1.2.3:9000, connection timeout 1 ms). (SOCKET_TIMEOUT) (version 25.3.6.10636.altinitytest (altinity build)) Code: 209. DB::NetException: Timeout: connect timed out: 128.1.2.3:9000 (128.1.2.3:9000, connection timeout 1 ms). (SOCKET_TIMEOUT) (version 25.3.6.10636.altinitytest (altinity build)) Code: 209. DB::NetException: Timeout: connect timed out: 128.1.2.3:9000 (128.1.2.3:9000, connection timeout 1 ms). (SOCKET_TIMEOUT) (version 25.3.6.10636.altinitytest (altinity build)) Code: 209. DB::NetException: Timeout: connect timed out: 128.1.2.3:9000 (128.1.2.3:9000, connection timeout 1 ms). (SOCKET_TIMEOUT) (version 25.3.6.10636.altinitytest (altinity build)) Code: 209. DB::NetException: Timeout: connect timed out: 128.1.2.3:9000 (128.1.2.3:9000, connection timeout 1 ms). (SOCKET_TIMEOUT) (version 25.3.6.10636.altinitytest (altinity build)) Code: 209. DB::NetException: Timeout: connect timed out: 128.1.2.3:9000 (128.1.2.3:9000, connection timeout 1 ms). (SOCKET_TIMEOUT) (version 25.3.6.10636.altinitytest (altinity build)) Code: 209. DB::NetException: Timeout: connect timed out: 128.1.2.3:9000 (128.1.2.3:9000, connection timeout 1 ms). (SOCKET_TIMEOUT) (version 25.3.6.10636.altinitytest (altinity build)) Code: 209. DB::NetException: Timeout: connect timed out: 128.1.2.3:9000 (128.1.2.3:9000, connection timeout 1 ms). (SOCKET_TIMEOUT) (version 25.3.6.10636.altinitytest (altinity build)) . (ALL_CONNECTION_TRIES_FAILED) (version 25.3.6.10636.altinitytest (altinity build)) . (NO_REMOTE_SHARD_AVAILABLE), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::NetException::NetException(int, FormatStringHelperImpl::type>, String&) @ 0x0000000016056ce9 3. /build/src/Storages/getStructureOfRemoteTable.cpp:177: DB::getStructureOfRemoteTable(DB::Cluster const&, DB::StorageID const&, std::shared_ptr, std::shared_ptr const&) @ 0x00000000160552a4 4. /build/src/TableFunctions/TableFunctionRemote.cpp:337: DB::TableFunctionRemote::getActualTableStructure(std::shared_ptr, bool) const @ 0x0000000011805ecb 5. /build/src/TableFunctions/TableFunctionRemote.cpp:309: DB::TableFunctionRemote::executeImpl(std::shared_ptr const&, std::shared_ptr, String const&, DB::ColumnsDescription, bool) const @ 0x00000000118056e0 6. /build/src/TableFunctions/ITableFunction.cpp:36: DB::ITableFunction::execute(std::shared_ptr const&, std::shared_ptr, String const&, DB::ColumnsDescription, bool, bool) const @ 0x00000000131e9fc3 7. /build/src/Interpreters/Context.cpp:2501: DB::Context::executeTableFunction(std::shared_ptr const&, std::shared_ptr const&) @ 0x00000000144345b2 8. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:4975: DB::QueryAnalyzer::resolveTableFunction(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&, bool) @ 0x000000001401e9f9 9. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5342: DB::QueryAnalyzer::resolveQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&) @ 0x00000000140452bf 10. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5597: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000140136f0 11. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000140127f9 12. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000014011fce 13. /build/src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000001406ce8a 14. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000014973b42 15. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000001497268d 16. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000014974d24 17. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001492924b 18. /build/src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88641 19. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 20. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 21. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 22. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 23. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 24. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 25. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 26. ? @ 0x00007fbc6213eac3 27. ? @ 0x00007fbc621d0850 2025.07.28 11:51:46.502958 [ 12807 ] {0bc17c39-814e-42de-bb8c-508fefb318a7} executeQuery: Code: 439. DB::Exception: Cannot schedule a task: failed to start the thread (threads=0, jobs=0). (CANNOT_SCHEDULE_TASK) (version 25.3.6.10636.altinitytest (altinity build)) (from [::1]:55942) (comment: 02902_diable_apply_deleted_mask.sql) (query 2, line 3) (in query: CREATE TABLE test_apply_deleted_mask (`id` Int64, `value` String) ENGINE = MergeTree ORDER BY id SETTINGS index_granularity = 1076, min_bytes_for_wide_part = 1073741824, ratio_of_defaults_for_sparse_serialization = 0.855963945388794, 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 = 218855625, compact_parts_max_granules_to_buffer = 114, compact_parts_merge_max_bytes_to_prefetch_part = 10911237, merge_max_block_size = 6768, old_parts_lifetime = 480., prefer_fetch_merged_part_size_threshold = 10737418240, vertical_merge_algorithm_min_rows_to_activate = 141459, vertical_merge_algorithm_min_columns_to_activate = 1, min_merge_bytes_to_use_direct_io = 8473889098, index_granularity_bytes = 18379260, 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 = false, enable_block_offset_column = true, cache_populated_by_fetch = false, marks_compress_block_size = 16960, primary_key_compress_block_size = 12434, 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. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000fccaeeb 4. /build/src/Common/ThreadPool.cpp:275: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000fccc813 5. /build/src/Common/ThreadPool.cpp:308: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fcc8286 6. /build/src/Common/ThreadPool.cpp:494: ThreadPoolImpl>::scheduleOrThrowOnError(std::function, Priority) @ 0x000000000fcc7a0e 7. /build/src/Common/threadPoolCallbackRunner.h:188: DB::ThreadPoolCallbackRunnerLocal>, std::function>::operator()(std::function&&, Priority, std::optional) @ 0x00000000119df78e 8. /build/src/Storages/MergeTree/MergeTreeData.cpp:1923: DB::MergeTreeData::loadDataParts(bool, std::optional, std::equal_to, std::allocator>>) @ 0x0000000016314fbd 9. /build/src/Storages/StorageMergeTree.cpp:161: 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>) @ 0x0000000016632c15 10. /build/contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: std::shared_ptr std::allocate_shared[abi:se190107], 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>&&) @ 0x00000000166326f0 11. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:851: DB::create(DB::StorageFactory::Arguments const&) @ 0x000000001662f01d 12. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000015d81ea2 13. /build/src/Interpreters/InterpreterCreateQuery.cpp:1945: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x00000000149009bb 14. /build/src/Interpreters/InterpreterCreateQuery.cpp:1743: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000148f9aa9 15. /build/src/Interpreters/InterpreterCreateQuery.cpp:2352: DB::InterpreterCreateQuery::execute() @ 0x0000000014905a41 16. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88dc9 17. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 18. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 19. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 20. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 21. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 22. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 23. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 24. ? @ 0x00007fbc6213eac3 25. ? @ 0x00007fbc621d0850 2025.07.28 11:51:46.518213 [ 12807 ] {} 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. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000fccaeeb 4. /build/src/Common/ThreadPool.cpp:275: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000fccc813 5. /build/src/Common/ThreadPool.cpp:308: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fcc8286 6. /build/src/Common/ThreadPool.cpp:494: ThreadPoolImpl>::scheduleOrThrowOnError(std::function, Priority) @ 0x000000000fcc7a0e 7. /build/src/Common/threadPoolCallbackRunner.h:188: DB::ThreadPoolCallbackRunnerLocal>, std::function>::operator()(std::function&&, Priority, std::optional) @ 0x00000000119df78e 8. /build/src/Storages/MergeTree/MergeTreeData.cpp:1923: DB::MergeTreeData::loadDataParts(bool, std::optional, std::equal_to, std::allocator>>) @ 0x0000000016314fbd 9. /build/src/Storages/StorageMergeTree.cpp:161: 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>) @ 0x0000000016632c15 10. /build/contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: std::shared_ptr std::allocate_shared[abi:se190107], 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>&&) @ 0x00000000166326f0 11. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:851: DB::create(DB::StorageFactory::Arguments const&) @ 0x000000001662f01d 12. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000015d81ea2 13. /build/src/Interpreters/InterpreterCreateQuery.cpp:1945: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x00000000149009bb 14. /build/src/Interpreters/InterpreterCreateQuery.cpp:1743: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000148f9aa9 15. /build/src/Interpreters/InterpreterCreateQuery.cpp:2352: DB::InterpreterCreateQuery::execute() @ 0x0000000014905a41 16. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88dc9 17. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 18. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 19. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 20. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 21. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 22. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 23. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 24. ? @ 0x00007fbc6213eac3 25. ? @ 0x00007fbc621d0850 2025.07.28 11:51:46.718046 [ 17256 ] {6b452f0f-a8af-4d38-b622-952fb319a335} executeQuery: Code: 439. DB::Exception: Cannot schedule a task: failed to start the thread (threads=0, jobs=0). (CANNOT_SCHEDULE_TASK) (version 25.3.6.10636.altinitytest (altinity build)) (from [::1]:55964) (comment: 01273_lc_fixed_string_field.sql) (query 1, line 1) (in query: CREATE TABLE t (`d` Date, `s` LowCardinality(FixedString(3)), `c` UInt32) ENGINE = SummingMergeTree PARTITION BY d ORDER BY (d, s) SETTINGS index_granularity = 42568, min_bytes_for_wide_part = 676061936, 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 = 498033118, compact_parts_max_granules_to_buffer = 1, compact_parts_merge_max_bytes_to_prefetch_part = 30517968, merge_max_block_size = 17083, old_parts_lifetime = 132., prefer_fetch_merged_part_size_threshold = 10722964142, vertical_merge_algorithm_min_rows_to_activate = 1000000, vertical_merge_algorithm_min_columns_to_activate = 100, min_merge_bytes_to_use_direct_io = 3117824457, index_granularity_bytes = 26013471, use_const_adaptive_granularity = false, 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 = true, cache_populated_by_fetch = false, marks_compress_block_size = 17075, primary_key_compress_block_size = 95646, 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. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000fccaeeb 4. /build/src/Common/ThreadPool.cpp:275: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000fccc813 5. /build/src/Common/ThreadPool.cpp:308: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fcc8286 6. /build/src/Common/ThreadPool.cpp:494: ThreadPoolImpl>::scheduleOrThrowOnError(std::function, Priority) @ 0x000000000fcc7a0e 7. /build/src/Common/threadPoolCallbackRunner.h:188: DB::ThreadPoolCallbackRunnerLocal>, std::function>::operator()(std::function&&, Priority, std::optional) @ 0x00000000119df78e 8. /build/src/Storages/MergeTree/MergeTreeData.cpp:1923: DB::MergeTreeData::loadDataParts(bool, std::optional, std::equal_to, std::allocator>>) @ 0x0000000016314fbd 9. /build/src/Storages/StorageMergeTree.cpp:161: 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>) @ 0x0000000016632c15 10. /build/contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: std::shared_ptr std::allocate_shared[abi:se190107], 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>&&) @ 0x00000000166326f0 11. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:851: DB::create(DB::StorageFactory::Arguments const&) @ 0x000000001662f01d 12. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000015d81ea2 13. /build/src/Interpreters/InterpreterCreateQuery.cpp:1945: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x00000000149009bb 14. /build/src/Interpreters/InterpreterCreateQuery.cpp:1743: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000148f9aa9 15. /build/src/Interpreters/InterpreterCreateQuery.cpp:2352: DB::InterpreterCreateQuery::execute() @ 0x0000000014905a41 16. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88dc9 17. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 18. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 19. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 20. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 21. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 22. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 23. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 24. ? @ 0x00007fbc6213eac3 25. ? @ 0x00007fbc621d0850 2025.07.28 11:51:46.759384 [ 17256 ] {} 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. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000fccaeeb 4. /build/src/Common/ThreadPool.cpp:275: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000fccc813 5. /build/src/Common/ThreadPool.cpp:308: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fcc8286 6. /build/src/Common/ThreadPool.cpp:494: ThreadPoolImpl>::scheduleOrThrowOnError(std::function, Priority) @ 0x000000000fcc7a0e 7. /build/src/Common/threadPoolCallbackRunner.h:188: DB::ThreadPoolCallbackRunnerLocal>, std::function>::operator()(std::function&&, Priority, std::optional) @ 0x00000000119df78e 8. /build/src/Storages/MergeTree/MergeTreeData.cpp:1923: DB::MergeTreeData::loadDataParts(bool, std::optional, std::equal_to, std::allocator>>) @ 0x0000000016314fbd 9. /build/src/Storages/StorageMergeTree.cpp:161: 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>) @ 0x0000000016632c15 10. /build/contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: std::shared_ptr std::allocate_shared[abi:se190107], 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>&&) @ 0x00000000166326f0 11. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:851: DB::create(DB::StorageFactory::Arguments const&) @ 0x000000001662f01d 12. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000015d81ea2 13. /build/src/Interpreters/InterpreterCreateQuery.cpp:1945: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x00000000149009bb 14. /build/src/Interpreters/InterpreterCreateQuery.cpp:1743: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000148f9aa9 15. /build/src/Interpreters/InterpreterCreateQuery.cpp:2352: DB::InterpreterCreateQuery::execute() @ 0x0000000014905a41 16. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88dc9 17. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 18. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 19. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 20. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 21. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 22. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 23. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 24. ? @ 0x00007fbc6213eac3 25. ? @ 0x00007fbc621d0850 2025.07.28 11:51:47.227318 [ 17252 ] {d0465a39-caf4-4831-9bdc-c66ae171e3c8} executeQuery: Code: 62. DB::Exception: Max query size exceeded (can be increased with the `max_query_size` setting): Syntax error: failed at position 8 ('ыыыыыыыыыыыыыыыыыыыыыыыыыыыыыыыыыыыыыыыыыыыыыыыыыыыыыыыыыыыыыыыыыыыыыыыыыыыыыыыыыыыыыыыыыыыыыыыыыыыыыыыыыыыыыыыыыыыыыыыыыыыыыыыыыыыыыыыыыыыыыыыыыыыыыыыыыыыыыыы...): 'ыыыыыыыыыыыыыыыыыыыыыыыыыыыыыыыыыыыыыыыыыыыыыыыыыыыыыыыыыыыыыыыыыыыыыыыыыыыыыыыыыыыыыыыыыыыыыыыыыыыыыыыыыыыыыыыыыыыыыыыыыыыыыыыыыыыыыыыыыыыыыыыыыыыыыыыыыыыыыыы... . (SYNTAX_ERROR) (version 25.3.6.10636.altinitytest (altinity build)) (from [::ffff:127.0.0.1]:55140) (comment: 03328_syntax_error_e) (in query: SELECT 'ыыыыыы), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:111: DB::Exception::createDeprecated(String const&, int, bool) @ 0x000000000a08e96d 3. /build/src/Parsers/parseQuery.cpp:411: DB::parseQueryAndMovePosition(DB::IParser&, char const*&, char const*, String const&, bool, unsigned long, unsigned long, unsigned long) @ 0x0000000017a96b2c 4. /build/src/Parsers/parseQuery.cpp:424: DB::parseQuery(DB::IParser&, char const*, char const*, String const&, unsigned long, unsigned long, unsigned long) @ 0x0000000017a96bbe 5. /build/src/Interpreters/executeQuery.cpp:955: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c8533e 6. /build/src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x0000000014c8ca7b 7. /build/src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000001686da12 8. /build/src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x0000000016870807 9. /build/src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x0000000016907e99 10. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 11. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 12. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 13. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 14. ? @ 0x00007fbc6213eac3 15. ? @ 0x00007fbc621d0850 2025.07.28 11:51:47.232398 [ 17252 ] {d0465a39-caf4-4831-9bdc-c66ae171e3c8} DynamicQueryHandler: Code: 62. DB::Exception: Max query size exceeded (can be increased with the `max_query_size` setting): Syntax error: failed at position 8 ('ыыыыыыыыыыыыыыыыыыыыыыыыыыыыыыыыыыыыыыыыыыыыыыыыыыыыыыыыыыыыыыыыыыыыыыыыыыыыыыыыыыыыыыыыыыыыыыыыыыыыыыыыыыыыыыыыыыыыыыыыыыыыыыыыыыыыыыыыыыыыыыыыыыыыыыыыыыыыыыы...): 'ыыыыыыыыыыыыыыыыыыыыыыыыыыыыыыыыыыыыыыыыыыыыыыыыыыыыыыыыыыыыыыыыыыыыыыыыыыыыыыыыыыыыыыыыыыыыыыыыыыыыыыыыыыыыыыыыыыыыыыыыыыыыыыыыыыыыыыыыыыыыыыыыыыыыыыыыыыыыыыы... . (SYNTAX_ERROR), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:111: DB::Exception::createDeprecated(String const&, int, bool) @ 0x000000000a08e96d 3. /build/src/Parsers/parseQuery.cpp:411: DB::parseQueryAndMovePosition(DB::IParser&, char const*&, char const*, String const&, bool, unsigned long, unsigned long, unsigned long) @ 0x0000000017a96b2c 4. /build/src/Parsers/parseQuery.cpp:424: DB::parseQuery(DB::IParser&, char const*, char const*, String const&, unsigned long, unsigned long, unsigned long) @ 0x0000000017a96bbe 5. /build/src/Interpreters/executeQuery.cpp:955: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c8533e 6. /build/src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x0000000014c8ca7b 7. /build/src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000001686da12 8. /build/src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x0000000016870807 9. /build/src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x0000000016907e99 10. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 11. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 12. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 13. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 14. ? @ 0x00007fbc6213eac3 15. ? @ 0x00007fbc621d0850 (version 25.3.6.10636.altinitytest (altinity build)) 2025.07.28 11:51:47.677948 [ 17958 ] {0fe2a4f9-3d12-419d-abad-db4dc2c538fa} executeQuery: Code: 62. DB::Exception: Unrecognized token: Syntax error: failed at position 8 (ы): ыыы'. . (SYNTAX_ERROR) (version 25.3.6.10636.altinitytest (altinity build)) (from [::ffff:127.0.0.1]:55154) (comment: 03328_syntax_error_exception.sh) (in query: SELECT ыыы'), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:111: DB::Exception::createDeprecated(String const&, int, bool) @ 0x000000000a08e96d 3. /build/src/Parsers/parseQuery.cpp:411: DB::parseQueryAndMovePosition(DB::IParser&, char const*&, char const*, String const&, bool, unsigned long, unsigned long, unsigned long) @ 0x0000000017a96b2c 4. /build/src/Parsers/parseQuery.cpp:424: DB::parseQuery(DB::IParser&, char const*, char const*, String const&, unsigned long, unsigned long, unsigned long) @ 0x0000000017a96bbe 5. /build/src/Interpreters/executeQuery.cpp:955: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c8533e 6. /build/src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x0000000014c8ca7b 7. /build/src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000001686da12 8. /build/src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x0000000016870807 9. /build/src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x0000000016907e99 10. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 11. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 12. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 13. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 14. ? @ 0x00007fbc6213eac3 15. ? @ 0x00007fbc621d0850 2025.07.28 11:51:47.679514 [ 17958 ] {0fe2a4f9-3d12-419d-abad-db4dc2c538fa} DynamicQueryHandler: Code: 62. DB::Exception: Unrecognized token: Syntax error: failed at position 8 (ы): ыыы'. . (SYNTAX_ERROR), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:111: DB::Exception::createDeprecated(String const&, int, bool) @ 0x000000000a08e96d 3. /build/src/Parsers/parseQuery.cpp:411: DB::parseQueryAndMovePosition(DB::IParser&, char const*&, char const*, String const&, bool, unsigned long, unsigned long, unsigned long) @ 0x0000000017a96b2c 4. /build/src/Parsers/parseQuery.cpp:424: DB::parseQuery(DB::IParser&, char const*, char const*, String const&, unsigned long, unsigned long, unsigned long) @ 0x0000000017a96bbe 5. /build/src/Interpreters/executeQuery.cpp:955: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c8533e 6. /build/src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x0000000014c8ca7b 7. /build/src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000001686da12 8. /build/src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x0000000016870807 9. /build/src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x0000000016907e99 10. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 11. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 12. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 13. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 14. ? @ 0x00007fbc6213eac3 15. ? @ 0x00007fbc621d0850 (version 25.3.6.10636.altinitytest (altinity build)) 2025.07.28 11:51:47.977014 [ 5747 ] {285b199c-4b1d-4142-ba42-370bca8006c3} executeQuery: Code: 47. DB::Exception: Unknown expression or function identifier `x` in scope x = 1. Maybe you meant: ['d']. (UNKNOWN_IDENTIFIER) (version 25.3.6.10636.altinitytest (altinity build)) (from [::1]:56002) (comment: 00327_summing_composite_nested.sql) (query 6, line 9) (in query: SELECT * FROM summing_composite_key ORDER BY d, k, FirstMap.k1, FirstMap.k2ID, FirstMap.s, SecondMap.k1ID, SecondMap.k2Key, SecondMap.k3Type, SecondMap.s;), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.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&&) @ 0x000000001404b3b9 4. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3771: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000001401b849 5. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3980: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000014018e31 6. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:2925: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000001402fcbd 7. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3838: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000014019a9e 8. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:209: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000001401270e 9. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000014011fce 10. /build/src/Planner/Utils.cpp:458: DB::buildFilterInfo(std::shared_ptr, std::shared_ptr const&, std::shared_ptr&, std::unordered_set, std::equal_to, std::allocator>) @ 0x0000000013fe8bcf 11. /build/src/Planner/PlannerJoinTree.cpp:535: DB::(anonymous namespace)::buildQueryPlanForTableExpression(std::shared_ptr, std::shared_ptr const&, DB::SelectQueryInfo const&, DB::SelectQueryOptions const&, std::shared_ptr&, bool, bool) @ 0x00000000149956d3 12. /build/src/Planner/PlannerJoinTree.cpp:2252: DB::buildJoinTreeQueryPlan(std::shared_ptr const&, DB::SelectQueryInfo const&, DB::SelectQueryOptions&, std::unordered_set, std::equal_to, std::allocator> const&, std::shared_ptr&) @ 0x000000001498e109 13. /build/src/Planner/Planner.cpp:1553: DB::Planner::buildPlanForQueryNode() @ 0x0000000014979dae 14. /build/src/Planner/Planner.cpp:1308: DB::Planner::buildQueryPlanIfNeeded() @ 0x000000001497685c 15. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:255: DB::InterpreterSelectQueryAnalyzer::getQueryPlan() @ 0x000000001497476d 16. /build/src/Interpreters/executeQuery.cpp:1405: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88806 17. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 18. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 19. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 20. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 21. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 22. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 23. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 24. ? @ 0x00007fbc6213eac3 25. ? @ 0x00007fbc621d0850 2025.07.28 11:51:47.983376 [ 5747 ] {} TCPHandler: Code: 47. DB::Exception: Unknown expression or function identifier `x` in scope x = 1. Maybe you meant: ['d']. (UNKNOWN_IDENTIFIER), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.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&&) @ 0x000000001404b3b9 4. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3771: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000001401b849 5. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3980: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000014018e31 6. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:2925: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000001402fcbd 7. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3838: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000014019a9e 8. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:209: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000001401270e 9. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000014011fce 10. /build/src/Planner/Utils.cpp:458: DB::buildFilterInfo(std::shared_ptr, std::shared_ptr const&, std::shared_ptr&, std::unordered_set, std::equal_to, std::allocator>) @ 0x0000000013fe8bcf 11. /build/src/Planner/PlannerJoinTree.cpp:535: DB::(anonymous namespace)::buildQueryPlanForTableExpression(std::shared_ptr, std::shared_ptr const&, DB::SelectQueryInfo const&, DB::SelectQueryOptions const&, std::shared_ptr&, bool, bool) @ 0x00000000149956d3 12. /build/src/Planner/PlannerJoinTree.cpp:2252: DB::buildJoinTreeQueryPlan(std::shared_ptr const&, DB::SelectQueryInfo const&, DB::SelectQueryOptions&, std::unordered_set, std::equal_to, std::allocator> const&, std::shared_ptr&) @ 0x000000001498e109 13. /build/src/Planner/Planner.cpp:1553: DB::Planner::buildPlanForQueryNode() @ 0x0000000014979dae 14. /build/src/Planner/Planner.cpp:1308: DB::Planner::buildQueryPlanIfNeeded() @ 0x000000001497685c 15. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:255: DB::InterpreterSelectQueryAnalyzer::getQueryPlan() @ 0x000000001497476d 16. /build/src/Interpreters/executeQuery.cpp:1405: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88806 17. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 18. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 19. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 20. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 21. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 22. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 23. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 24. ? @ 0x00007fbc6213eac3 25. ? @ 0x00007fbc621d0850 2025.07.28 11:51:50.424580 [ 17251 ] {d3d46c39-6c52-4653-b272-2d284d0b3fea} executeQuery: Code: 440. DB::Exception: LIMIT expression must be constant with numeric type. Actual arrayJoin([1, 2]). In scope SELECT * FROM system.numbers LIMIT arrayJoin([1, 2]). (INVALID_LIMIT_EXPRESSION) (version 25.3.6.10636.altinitytest (altinity build)) (from [::1]:55988) (comment: 01165_lost_part_empty_partition.sql) (query 6, line 11) (in query: insert into rmt1(n) select * from system.numbers limit arrayJoin([1, 2]);), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, String&&, String&&) @ 0x000000001098ed2b 4. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:876: DB::QueryAnalyzer::convertLimitOffsetExpression(std::shared_ptr&, String const&, DB::IdentifierResolveScope&) @ 0x0000000014026486 5. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5684: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000014014161 6. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000140127f9 7. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000014011fce 8. /build/src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000001406ce8a 9. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000014973b42 10. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000001497268d 11. /build/src/Interpreters/InterpreterInsertQuery.cpp:578: DB::InterpreterInsertQuery::buildInsertSelectPipeline(DB::ASTInsertQuery&, std::shared_ptr) @ 0x00000000149303a2 12. /build/src/Interpreters/InterpreterInsertQuery.cpp:870: DB::InterpreterInsertQuery::execute() @ 0x0000000014933e3d 13. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88dc9 14. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 15. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 16. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 17. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 18. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 19. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 20. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 21. ? @ 0x00007fbc6213eac3 22. ? @ 0x00007fbc621d0850 2025.07.28 11:51:50.429402 [ 17251 ] {} TCPHandler: Code: 440. DB::Exception: LIMIT expression must be constant with numeric type. Actual arrayJoin([1, 2]). In scope SELECT * FROM system.numbers LIMIT arrayJoin([1, 2]). (INVALID_LIMIT_EXPRESSION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, String&&, String&&) @ 0x000000001098ed2b 4. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:876: DB::QueryAnalyzer::convertLimitOffsetExpression(std::shared_ptr&, String const&, DB::IdentifierResolveScope&) @ 0x0000000014026486 5. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5684: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000014014161 6. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000140127f9 7. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000014011fce 8. /build/src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000001406ce8a 9. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000014973b42 10. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000001497268d 11. /build/src/Interpreters/InterpreterInsertQuery.cpp:578: DB::InterpreterInsertQuery::buildInsertSelectPipeline(DB::ASTInsertQuery&, std::shared_ptr) @ 0x00000000149303a2 12. /build/src/Interpreters/InterpreterInsertQuery.cpp:870: DB::InterpreterInsertQuery::execute() @ 0x0000000014933e3d 13. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88dc9 14. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 15. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 16. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 17. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 18. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 19. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 20. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 21. ? @ 0x00007fbc6213eac3 22. ? @ 0x00007fbc621d0850 2025.07.28 11:51:50.947719 [ 3974 ] {} test_13.rmt2 (7f9b740d-015c-470e-8cc6-8ba33be0dc63): auto DB::StorageReplicatedMergeTree::processQueueEntry(ReplicatedMergeTreeQueue::SelectedEntryPtr)::(anonymous class)::operator()(LogEntryPtr &) const: Code: 86. DB::HTTPException: Received error from remote server http://146b4357c08d:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Ftest%2F01165%2Ftest_13%2Frmt%2Freplicas%2F1&part=20250728_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.6.10636.altinitytest (altinity build)) '. (RECEIVED_ERROR_FROM_REMOTE_IO_SERVER), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.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 const&, int&&, String const&, unsigned long&&, String const&) @ 0x000000000feda8d9 4. /build/src/IO/HTTPCommon.cpp:104: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x000000000feda6e2 5. /build/src/IO/HTTPCommon.cpp:93: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x000000000feda537 6. /build/src/IO/ReadWriteBufferFromHTTP.cpp:277: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x000000001184a4c4 7. /build/src/IO/ReadWriteBufferFromHTTP.cpp:285: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x000000001184a615 8. /build/src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x000000001184ae59 9. /build/src/IO/ReadWriteBufferFromHTTP.cpp:472: void std::__function::__policy_invoker::__call_impl[abi:se190107]>(std::__function::__policy_storage const*) @ 0x000000001184cedd 10. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001184858b 11. /build/src/IO/ReadWriteBufferFromHTTP.cpp:465: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x000000001184bf0b 12. /build/src/IO/ReadBuffer.h:60: DB::ReadBuffer::next() @ 0x000000000a148c7b 13. /build/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) @ 0x0000000011849fb2 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]>&)>&, 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&) @ 0x0000000011841980 15. /build/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) @ 0x000000001621208e 16. /build/src/Storages/StorageReplicatedMergeTree.cpp:5228: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl[abi:se190107] const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000015f9a5fe 17. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000015ed8bfd 18. /build/src/Storages/StorageReplicatedMergeTree.cpp:2514: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x0000000015ec9aab 19. /build/src/Storages/StorageReplicatedMergeTree.cpp:2349: DB::StorageReplicatedMergeTree::executeLogEntry(DB::ReplicatedMergeTreeLogEntry&) @ 0x0000000015eba91b 20. /build/src/Storages/StorageReplicatedMergeTree.cpp:3876: bool std::__function::__policy_invoker&)>::__call_impl[abi:se190107])::$_1, bool (std::shared_ptr&)>>(std::__function::__policy_storage const*, std::shared_ptr&) @ 0x0000000015f9837e 21. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000165d6fc3 22. /build/src/Storages/StorageReplicatedMergeTree.cpp:3872: DB::StorageReplicatedMergeTree::processQueueEntry(std::shared_ptr) @ 0x0000000015efc18a 23. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001624c1b2 24. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000162f9c70 25. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x00000000162fa55a 26. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc6653 27. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000000fccc4c3 28. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc3d92 29. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fcca080 30. ? @ 0x00007fbc6213eac3 31. ? @ 0x00007fbc621d0850 (version 25.3.6.10636.altinitytest (altinity build)) 2025.07.28 11:51:51.175919 [ 3961 ] {} test_13.rmt2 (7f9b740d-015c-470e-8cc6-8ba33be0dc63): auto DB::StorageReplicatedMergeTree::processQueueEntry(ReplicatedMergeTreeQueue::SelectedEntryPtr)::(anonymous class)::operator()(LogEntryPtr &) const: Code: 86. DB::HTTPException: Received error from remote server http://146b4357c08d:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Ftest%2F01165%2Ftest_13%2Frmt%2Freplicas%2F1&part=20250728_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.6.10636.altinitytest (altinity build)) '. (RECEIVED_ERROR_FROM_REMOTE_IO_SERVER), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.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 const&, int&&, String const&, unsigned long&&, String const&) @ 0x000000000feda8d9 4. /build/src/IO/HTTPCommon.cpp:104: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x000000000feda6e2 5. /build/src/IO/HTTPCommon.cpp:93: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x000000000feda537 6. /build/src/IO/ReadWriteBufferFromHTTP.cpp:277: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x000000001184a4c4 7. /build/src/IO/ReadWriteBufferFromHTTP.cpp:285: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x000000001184a615 8. /build/src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x000000001184ae59 9. /build/src/IO/ReadWriteBufferFromHTTP.cpp:472: void std::__function::__policy_invoker::__call_impl[abi:se190107]>(std::__function::__policy_storage const*) @ 0x000000001184cedd 10. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001184858b 11. /build/src/IO/ReadWriteBufferFromHTTP.cpp:465: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x000000001184bf0b 12. /build/src/IO/ReadBuffer.h:60: DB::ReadBuffer::next() @ 0x000000000a148c7b 13. /build/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) @ 0x0000000011849fb2 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]>&)>&, 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&) @ 0x0000000011841980 15. /build/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) @ 0x000000001621208e 16. /build/src/Storages/StorageReplicatedMergeTree.cpp:5228: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl[abi:se190107] const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000015f9a5fe 17. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000015ed8bfd 18. /build/src/Storages/StorageReplicatedMergeTree.cpp:2514: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x0000000015ec9aab 19. /build/src/Storages/StorageReplicatedMergeTree.cpp:2349: DB::StorageReplicatedMergeTree::executeLogEntry(DB::ReplicatedMergeTreeLogEntry&) @ 0x0000000015eba91b 20. /build/src/Storages/StorageReplicatedMergeTree.cpp:3876: bool std::__function::__policy_invoker&)>::__call_impl[abi:se190107])::$_1, bool (std::shared_ptr&)>>(std::__function::__policy_storage const*, std::shared_ptr&) @ 0x0000000015f9837e 21. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000165d6fc3 22. /build/src/Storages/StorageReplicatedMergeTree.cpp:3872: DB::StorageReplicatedMergeTree::processQueueEntry(std::shared_ptr) @ 0x0000000015efc18a 23. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001624c1b2 24. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000162f9c70 25. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x00000000162fa55a 26. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc6653 27. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000000fccc4c3 28. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc3d92 29. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fcca080 30. ? @ 0x00007fbc6213eac3 31. ? @ 0x00007fbc621d0850 (version 25.3.6.10636.altinitytest (altinity build)) 2025.07.28 11:51:51.737589 [ 4900 ] {74d85d6d-8986-4486-a2aa-418348d02db1} executeQuery: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=14, jobs=4): (while reading prefix of column json): (while reading from part /var/lib/clickhouse/store/f52/f52ba062-e9ea-4464-b601-7c63efed68b8/all_1_6_1/ in table test_xmxwwivj.test (f52ba062-e9ea-4464-b601-7c63efed68b8) located on disk default of type local, from mark 0 with max_rows_to_read = 30): While executing MergeTreeSelect(pool: ReadPoolInOrder, algorithm: InOrder). (CANNOT_SCHEDULE_TASK) (version 25.3.6.10636.altinitytest (altinity build)) (from [::1]:33042) (comment: 03207_json_read_subcolumns_1_wide_merge_tree.gen.sql) (query 24, line 32) (in query: select json, json.non.existing.path, json.non.existing.path.:Int64 from test order by id format JSONColumns;), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000fccaeeb 4. /build/src/Common/ThreadPool.cpp:275: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000fccc813 5. /build/src/Common/ThreadPool.cpp:323: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fcc7bbc 6. /build/src/Common/ThreadPool.cpp:494: ThreadPoolImpl>::scheduleOrThrowOnError(std::function, Priority) @ 0x000000000fcc7a0e 7. /build/src/Common/threadPoolCallbackRunner.h:52: std::future> std::__function::__policy_invoker> (DB::MergeTreeMarksLoader::loadMarksAsync()::$_0&&, Priority)>::__call_impl[abi:se190107]> (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&&) @ 0x0000000016474731 8. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000016471940 9. /build/src/Storages/MergeTree/MergeTreeMarksLoader.cpp:83: DB::MergeTreeMarksLoader::startAsyncLoad() @ 0x000000001647173f 10. /build/src/Storages/MergeTree/MergeTreeReaderWide.cpp:294: DB::MergeTreeReaderWide::addStream(DB::ISerialization::SubstreamPath const&, String const&) @ 0x00000000164aa163 11. /build/src/Storages/MergeTree/MergeTreeReaderWide.cpp:376: void std::__function::__policy_invoker::__call_impl[abi:se190107] 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&) @ 0x00000000164ab79d 12. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000013cf3e04 13. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000013c7aa09 14. /build/src/DataTypes/Serializations/SerializationVariant.cpp:101: DB::SerializationVariant::enumerateStreams(DB::ISerialization::EnumerateStreamsSettings&, std::function const&, DB::ISerialization::SubstreamData const&) const @ 0x0000000013d2c5e5 15. /build/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 @ 0x0000000013c99d73 16. /build/src/DataTypes/Serializations/SerializationObject.cpp:445: void std::__function::__policy_invoker::__call_impl[abi:se190107]&, std::unordered_map, std::hash, std::equal_to, std::allocator>>>*) const::$_4, void ()>>(std::__function::__policy_storage const*) @ 0x0000000013cf3c2e 17. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000013cea1a0 18. /build/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) @ 0x00000000164aa967 19. /build/src/Storages/MergeTree/MergeTreeReaderWide.cpp:397: DB::MergeTreeReaderWide::deserializePrefixForAllColumnsImpl(unsigned long, unsigned long, unsigned long, std::function (DB::NameAndTypePair const&)>)::$_0::operator()() const @ 0x00000000164aafe2 20. /build/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:se190107] (DB::NameAndTypePair const&)>)::$_0, std::unordered_map, std::hash, std::equal_to, std::allocator>>> ()>>(std::__function::__policy_storage const*) @ 0x00000000164ab84c 21. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000164ad047 22. /build/src/Storages/MergeTree/MergeTreeReaderWide.cpp:420: DB::MergeTreeReaderWide::deserializePrefixForAllColumnsImpl(unsigned long, unsigned long, unsigned long, std::function (DB::NameAndTypePair const&)>) @ 0x00000000164aab4e 23. /build/src/Storages/MergeTree/MergeTreeReaderWide.cpp:427: DB::MergeTreeReaderWide::readRows(unsigned long, unsigned long, bool, unsigned long, std::vector::immutable_ptr, std::allocator::immutable_ptr>>&) @ 0x00000000164a920e 24. /build/src/Storages/MergeTree/MergeTreeRangeReader.cpp:116: DB::MergeTreeRangeReader::DelayedStream::finalize(std::vector::immutable_ptr, std::allocator::immutable_ptr>>&) @ 0x0000000016497db1 25. /build/src/Storages/MergeTree/MergeTreeRangeReader.cpp:298: DB::MergeTreeRangeReader::startReadingChain(unsigned long, DB::MarkRanges&) @ 0x000000001649f129 26. /build/src/Storages/MergeTree/MergeTreeReadersChain.cpp:67: DB::MergeTreeReadersChain::read(unsigned long, DB::MarkRanges&) @ 0x00000000164b9dda 27. /build/src/Storages/MergeTree/MergeTreeReadTask.cpp:172: DB::MergeTreeReadTask::read() @ 0x00000000164b6300 28. /build/src/Storages/MergeTree/MergeTreeSelectAlgorithms.h:53: DB::MergeTreeInOrderSelectAlgorithm::readFromTask(DB::MergeTreeReadTask&) @ 0x0000000016e56d4c 29. /build/src/Storages/MergeTree/MergeTreeSelectProcessor.cpp:207: DB::MergeTreeSelectProcessor::read() @ 0x00000000164c0ba4 30. /build/src/Storages/MergeTree/MergeTreeSource.cpp:229: DB::MergeTreeSource::tryGenerate() @ 0x0000000016e43d69 31. /build/src/Processors/ISource.cpp:108: DB::ISource::work() @ 0x00000000169a21e7 2025.07.28 11:51:51.781105 [ 4900 ] {} TCPHandler: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=14, jobs=4): (while reading prefix of column json): (while reading from part /var/lib/clickhouse/store/f52/f52ba062-e9ea-4464-b601-7c63efed68b8/all_1_6_1/ in table test_xmxwwivj.test (f52ba062-e9ea-4464-b601-7c63efed68b8) located on disk default of type local, from mark 0 with max_rows_to_read = 30): While executing MergeTreeSelect(pool: ReadPoolInOrder, algorithm: InOrder). (CANNOT_SCHEDULE_TASK), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000fccaeeb 4. /build/src/Common/ThreadPool.cpp:275: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000fccc813 5. /build/src/Common/ThreadPool.cpp:323: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fcc7bbc 6. /build/src/Common/ThreadPool.cpp:494: ThreadPoolImpl>::scheduleOrThrowOnError(std::function, Priority) @ 0x000000000fcc7a0e 7. /build/src/Common/threadPoolCallbackRunner.h:52: std::future> std::__function::__policy_invoker> (DB::MergeTreeMarksLoader::loadMarksAsync()::$_0&&, Priority)>::__call_impl[abi:se190107]> (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&&) @ 0x0000000016474731 8. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000016471940 9. /build/src/Storages/MergeTree/MergeTreeMarksLoader.cpp:83: DB::MergeTreeMarksLoader::startAsyncLoad() @ 0x000000001647173f 10. /build/src/Storages/MergeTree/MergeTreeReaderWide.cpp:294: DB::MergeTreeReaderWide::addStream(DB::ISerialization::SubstreamPath const&, String const&) @ 0x00000000164aa163 11. /build/src/Storages/MergeTree/MergeTreeReaderWide.cpp:376: void std::__function::__policy_invoker::__call_impl[abi:se190107] 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&) @ 0x00000000164ab79d 12. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000013cf3e04 13. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000013c7aa09 14. /build/src/DataTypes/Serializations/SerializationVariant.cpp:101: DB::SerializationVariant::enumerateStreams(DB::ISerialization::EnumerateStreamsSettings&, std::function const&, DB::ISerialization::SubstreamData const&) const @ 0x0000000013d2c5e5 15. /build/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 @ 0x0000000013c99d73 16. /build/src/DataTypes/Serializations/SerializationObject.cpp:445: void std::__function::__policy_invoker::__call_impl[abi:se190107]&, std::unordered_map, std::hash, std::equal_to, std::allocator>>>*) const::$_4, void ()>>(std::__function::__policy_storage const*) @ 0x0000000013cf3c2e 17. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000013cea1a0 18. /build/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) @ 0x00000000164aa967 19. /build/src/Storages/MergeTree/MergeTreeReaderWide.cpp:397: DB::MergeTreeReaderWide::deserializePrefixForAllColumnsImpl(unsigned long, unsigned long, unsigned long, std::function (DB::NameAndTypePair const&)>)::$_0::operator()() const @ 0x00000000164aafe2 20. /build/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:se190107] (DB::NameAndTypePair const&)>)::$_0, std::unordered_map, std::hash, std::equal_to, std::allocator>>> ()>>(std::__function::__policy_storage const*) @ 0x00000000164ab84c 21. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000164ad047 22. /build/src/Storages/MergeTree/MergeTreeReaderWide.cpp:420: DB::MergeTreeReaderWide::deserializePrefixForAllColumnsImpl(unsigned long, unsigned long, unsigned long, std::function (DB::NameAndTypePair const&)>) @ 0x00000000164aab4e 23. /build/src/Storages/MergeTree/MergeTreeReaderWide.cpp:427: DB::MergeTreeReaderWide::readRows(unsigned long, unsigned long, bool, unsigned long, std::vector::immutable_ptr, std::allocator::immutable_ptr>>&) @ 0x00000000164a920e 24. /build/src/Storages/MergeTree/MergeTreeRangeReader.cpp:116: DB::MergeTreeRangeReader::DelayedStream::finalize(std::vector::immutable_ptr, std::allocator::immutable_ptr>>&) @ 0x0000000016497db1 25. /build/src/Storages/MergeTree/MergeTreeRangeReader.cpp:298: DB::MergeTreeRangeReader::startReadingChain(unsigned long, DB::MarkRanges&) @ 0x000000001649f129 26. /build/src/Storages/MergeTree/MergeTreeReadersChain.cpp:67: DB::MergeTreeReadersChain::read(unsigned long, DB::MarkRanges&) @ 0x00000000164b9dda 27. /build/src/Storages/MergeTree/MergeTreeReadTask.cpp:172: DB::MergeTreeReadTask::read() @ 0x00000000164b6300 28. /build/src/Storages/MergeTree/MergeTreeSelectAlgorithms.h:53: DB::MergeTreeInOrderSelectAlgorithm::readFromTask(DB::MergeTreeReadTask&) @ 0x0000000016e56d4c 29. /build/src/Storages/MergeTree/MergeTreeSelectProcessor.cpp:207: DB::MergeTreeSelectProcessor::read() @ 0x00000000164c0ba4 30. /build/src/Storages/MergeTree/MergeTreeSource.cpp:229: DB::MergeTreeSource::tryGenerate() @ 0x0000000016e43d69 31. /build/src/Processors/ISource.cpp:108: DB::ISource::work() @ 0x00000000169a21e7 Job's origin stack trace: 0. /build/src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000000fc33b84 1. /build/src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000000fcc2ea7 2. /build/src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fcc535c 3. /build/src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000000fcc584d 4. /build/src/Common/ThreadPool.h:279: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x00000000169bf193 5. /build/src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x00000000169bf518 6. /build/src/Server/TCPHandler.cpp:1237: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x00000000168f1525 7. /build/src/Server/TCPHandler.cpp:678: DB::TCPHandler::runImpl() @ 0x00000000168e68e5 8. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 9. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 10. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 11. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 12. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 13. ? @ 0x00007fbc6213eac3 14. ? @ 0x00007fbc621d0850 2025.07.28 11:51:51.857755 [ 17232 ] {6628332b-eff0-49ee-be74-ceb0a43d73fc} executeQuery: Code: 219. DB::Exception: New table appeared in database being dropped or detached. Try again. (DATABASE_NOT_EMPTY) (version 25.3.6.10636.altinitytest (altinity build)) (from [::1]:48442) (comment: 03207_json_read_subcolumns_1_wide_merge_tree.gen.sql) (in query: DROP DATABASE IF EXISTS test_xmxwwivj SYNC ), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000000a074fcb 4. /build/src/Interpreters/DatabaseCatalog.cpp:608: DB::DatabaseCatalog::detachDatabase(std::shared_ptr, String const&, bool, bool) @ 0x00000000144f41b9 5. /build/src/Interpreters/InterpreterDropQuery.cpp:482: DB::InterpreterDropQuery::executeToDatabaseImpl(DB::ASTDropQuery const&, std::shared_ptr&, std::vector, DB::UUIDTag>, std::allocator, DB::UUIDTag>>>&) @ 0x00000000149179be 6. /build/src/Interpreters/InterpreterDropQuery.cpp:363: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x0000000014913988 7. /build/src/Interpreters/InterpreterDropQuery.cpp:99: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000014913142 8. /build/src/Interpreters/InterpreterDropQuery.cpp:72: DB::InterpreterDropQuery::execute() @ 0x0000000014912b65 9. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88dc9 10. /build/src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x0000000014c8ca7b 11. /build/src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000001686da12 12. /build/src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x0000000016870807 13. /build/src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x0000000016907e99 14. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 15. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 16. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 17. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 18. ? @ 0x00007fbc6213eac3 19. ? @ 0x00007fbc621d0850 2025.07.28 11:51:51.863407 [ 17232 ] {6628332b-eff0-49ee-be74-ceb0a43d73fc} 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. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000000a074fcb 4. /build/src/Interpreters/DatabaseCatalog.cpp:608: DB::DatabaseCatalog::detachDatabase(std::shared_ptr, String const&, bool, bool) @ 0x00000000144f41b9 5. /build/src/Interpreters/InterpreterDropQuery.cpp:482: DB::InterpreterDropQuery::executeToDatabaseImpl(DB::ASTDropQuery const&, std::shared_ptr&, std::vector, DB::UUIDTag>, std::allocator, DB::UUIDTag>>>&) @ 0x00000000149179be 6. /build/src/Interpreters/InterpreterDropQuery.cpp:363: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x0000000014913988 7. /build/src/Interpreters/InterpreterDropQuery.cpp:99: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000014913142 8. /build/src/Interpreters/InterpreterDropQuery.cpp:72: DB::InterpreterDropQuery::execute() @ 0x0000000014912b65 9. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88dc9 10. /build/src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x0000000014c8ca7b 11. /build/src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000001686da12 12. /build/src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x0000000016870807 13. /build/src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x0000000016907e99 14. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 15. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 16. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 17. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 18. ? @ 0x00007fbc6213eac3 19. ? @ 0x00007fbc621d0850 (version 25.3.6.10636.altinitytest (altinity build)) 2025.07.28 11:51:51.942784 [ 17081 ] {9573c577-65b5-4222-98e4-6aef01d11f9a} executeQuery: Code: 47. DB::Exception: Unknown expression or function identifier `x` in scope x = 1. (UNKNOWN_IDENTIFIER) (version 25.3.6.10636.altinitytest (altinity build)) (from [::1]:56232) (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. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.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&&) @ 0x000000001404b3b9 4. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3771: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000001401b849 5. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3980: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000014018e31 6. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:2925: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000001402fcbd 7. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3838: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000014019a9e 8. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:209: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000001401270e 9. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000014011fce 10. /build/src/Planner/Utils.cpp:458: DB::buildFilterInfo(std::shared_ptr, std::shared_ptr const&, std::shared_ptr&, std::unordered_set, std::equal_to, std::allocator>) @ 0x0000000013fe8bcf 11. /build/src/Planner/PlannerJoinTree.cpp:535: DB::(anonymous namespace)::buildQueryPlanForTableExpression(std::shared_ptr, std::shared_ptr const&, DB::SelectQueryInfo const&, DB::SelectQueryOptions const&, std::shared_ptr&, bool, bool) @ 0x00000000149956d3 12. /build/src/Planner/PlannerJoinTree.cpp:2252: DB::buildJoinTreeQueryPlan(std::shared_ptr const&, DB::SelectQueryInfo const&, DB::SelectQueryOptions&, std::unordered_set, std::equal_to, std::allocator> const&, std::shared_ptr&) @ 0x000000001498e109 13. /build/src/Planner/Planner.cpp:1553: DB::Planner::buildPlanForQueryNode() @ 0x0000000014979dae 14. /build/src/Planner/Planner.cpp:1308: DB::Planner::buildQueryPlanIfNeeded() @ 0x000000001497685c 15. /build/src/Planner/PlannerJoinTree.cpp:1202: DB::(anonymous namespace)::buildQueryPlanForTableExpression(std::shared_ptr, std::shared_ptr const&, DB::SelectQueryInfo const&, DB::SelectQueryOptions const&, std::shared_ptr&, bool, bool) @ 0x0000000014994644 16. /build/src/Planner/PlannerJoinTree.cpp:2252: DB::buildJoinTreeQueryPlan(std::shared_ptr const&, DB::SelectQueryInfo const&, DB::SelectQueryOptions&, std::unordered_set, std::equal_to, std::allocator> const&, std::shared_ptr&) @ 0x000000001498e109 17. /build/src/Planner/Planner.cpp:1553: DB::Planner::buildPlanForQueryNode() @ 0x0000000014979dae 18. /build/src/Planner/Planner.cpp:1308: DB::Planner::buildQueryPlanIfNeeded() @ 0x000000001497685c 19. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:255: DB::InterpreterSelectQueryAnalyzer::getQueryPlan() @ 0x000000001497476d 20. /build/src/Interpreters/executeQuery.cpp:1405: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88806 21. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 22. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 23. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 24. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 25. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 26. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 27. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 28. ? @ 0x00007fbc6213eac3 29. ? @ 0x00007fbc621d0850 2025.07.28 11:51:51.954354 [ 17081 ] {} TCPHandler: Code: 47. DB::Exception: Unknown expression or function identifier `x` in scope x = 1. (UNKNOWN_IDENTIFIER), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.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&&) @ 0x000000001404b3b9 4. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3771: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000001401b849 5. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3980: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000014018e31 6. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:2925: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000001402fcbd 7. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3838: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000014019a9e 8. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:209: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000001401270e 9. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000014011fce 10. /build/src/Planner/Utils.cpp:458: DB::buildFilterInfo(std::shared_ptr, std::shared_ptr const&, std::shared_ptr&, std::unordered_set, std::equal_to, std::allocator>) @ 0x0000000013fe8bcf 11. /build/src/Planner/PlannerJoinTree.cpp:535: DB::(anonymous namespace)::buildQueryPlanForTableExpression(std::shared_ptr, std::shared_ptr const&, DB::SelectQueryInfo const&, DB::SelectQueryOptions const&, std::shared_ptr&, bool, bool) @ 0x00000000149956d3 12. /build/src/Planner/PlannerJoinTree.cpp:2252: DB::buildJoinTreeQueryPlan(std::shared_ptr const&, DB::SelectQueryInfo const&, DB::SelectQueryOptions&, std::unordered_set, std::equal_to, std::allocator> const&, std::shared_ptr&) @ 0x000000001498e109 13. /build/src/Planner/Planner.cpp:1553: DB::Planner::buildPlanForQueryNode() @ 0x0000000014979dae 14. /build/src/Planner/Planner.cpp:1308: DB::Planner::buildQueryPlanIfNeeded() @ 0x000000001497685c 15. /build/src/Planner/PlannerJoinTree.cpp:1202: DB::(anonymous namespace)::buildQueryPlanForTableExpression(std::shared_ptr, std::shared_ptr const&, DB::SelectQueryInfo const&, DB::SelectQueryOptions const&, std::shared_ptr&, bool, bool) @ 0x0000000014994644 16. /build/src/Planner/PlannerJoinTree.cpp:2252: DB::buildJoinTreeQueryPlan(std::shared_ptr const&, DB::SelectQueryInfo const&, DB::SelectQueryOptions&, std::unordered_set, std::equal_to, std::allocator> const&, std::shared_ptr&) @ 0x000000001498e109 17. /build/src/Planner/Planner.cpp:1553: DB::Planner::buildPlanForQueryNode() @ 0x0000000014979dae 18. /build/src/Planner/Planner.cpp:1308: DB::Planner::buildQueryPlanIfNeeded() @ 0x000000001497685c 19. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:255: DB::InterpreterSelectQueryAnalyzer::getQueryPlan() @ 0x000000001497476d 20. /build/src/Interpreters/executeQuery.cpp:1405: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88806 21. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 22. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 23. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 24. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 25. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 26. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 27. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 28. ? @ 0x00007fbc6213eac3 29. ? @ 0x00007fbc621d0850 2025.07.28 11:51:52.047849 [ 3962 ] {} test_13.rmt2 (7f9b740d-015c-470e-8cc6-8ba33be0dc63): auto DB::StorageReplicatedMergeTree::processQueueEntry(ReplicatedMergeTreeQueue::SelectedEntryPtr)::(anonymous class)::operator()(LogEntryPtr &) const: Code: 86. DB::HTTPException: Received error from remote server http://146b4357c08d:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Ftest%2F01165%2Ftest_13%2Frmt%2Freplicas%2F1&part=20250728_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.6.10636.altinitytest (altinity build)) '. (RECEIVED_ERROR_FROM_REMOTE_IO_SERVER), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.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 const&, int&&, String const&, unsigned long&&, String const&) @ 0x000000000feda8d9 4. /build/src/IO/HTTPCommon.cpp:104: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x000000000feda6e2 5. /build/src/IO/HTTPCommon.cpp:93: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x000000000feda537 6. /build/src/IO/ReadWriteBufferFromHTTP.cpp:277: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x000000001184a4c4 7. /build/src/IO/ReadWriteBufferFromHTTP.cpp:285: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x000000001184a615 8. /build/src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x000000001184ae59 9. /build/src/IO/ReadWriteBufferFromHTTP.cpp:472: void std::__function::__policy_invoker::__call_impl[abi:se190107]>(std::__function::__policy_storage const*) @ 0x000000001184cedd 10. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001184858b 11. /build/src/IO/ReadWriteBufferFromHTTP.cpp:465: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x000000001184bf0b 12. /build/src/IO/ReadBuffer.h:60: DB::ReadBuffer::next() @ 0x000000000a148c7b 13. /build/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) @ 0x0000000011849fb2 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]>&)>&, 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&) @ 0x0000000011841980 15. /build/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) @ 0x000000001621208e 16. /build/src/Storages/StorageReplicatedMergeTree.cpp:5228: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl[abi:se190107] const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000015f9a5fe 17. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000015ed8bfd 18. /build/src/Storages/StorageReplicatedMergeTree.cpp:2514: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x0000000015ec9aab 19. /build/src/Storages/StorageReplicatedMergeTree.cpp:2349: DB::StorageReplicatedMergeTree::executeLogEntry(DB::ReplicatedMergeTreeLogEntry&) @ 0x0000000015eba91b 20. /build/src/Storages/StorageReplicatedMergeTree.cpp:3876: bool std::__function::__policy_invoker&)>::__call_impl[abi:se190107])::$_1, bool (std::shared_ptr&)>>(std::__function::__policy_storage const*, std::shared_ptr&) @ 0x0000000015f9837e 21. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000165d6fc3 22. /build/src/Storages/StorageReplicatedMergeTree.cpp:3872: DB::StorageReplicatedMergeTree::processQueueEntry(std::shared_ptr) @ 0x0000000015efc18a 23. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001624c1b2 24. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000162f9c70 25. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x00000000162fa55a 26. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc6653 27. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000000fccc4c3 28. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc3d92 29. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fcca080 30. ? @ 0x00007fbc6213eac3 31. ? @ 0x00007fbc621d0850 (version 25.3.6.10636.altinitytest (altinity build)) 2025.07.28 11:51:52.097660 [ 17207 ] {392e4d77-839b-4e8a-a49e-2f1ac48373a5} executeQuery: Code: 36. DB::Exception: Materialized view test_5.v cannot point to itself. (BAD_ARGUMENTS) (version 25.3.6.10636.altinitytest (altinity build)) (from 0.0.0.0:0) (comment: 01527_materialized_view_stack_overflow.sql) (in query: /* ddl_entry=query-0000000051 */ CREATE MATERIALIZED VIEW test_5.v UUID '7683dc86-2f20-4315-9821-4fd5beca2dbb' TO test_5.v (`c` String) AS SELECT c FROM test_5.t), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x000000000a06b56b 4. /build/src/Storages/StorageMaterializedView.cpp:168: DB::StorageMaterializedView::StorageMaterializedView(DB::StorageID const&, std::shared_ptr, DB::ASTCreateQuery const&, DB::ColumnsDescription const&, DB::LoadingStrictnessLevel, String const&, bool) @ 0x0000000015e1ca9a 5. /build/contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: std::shared_ptr std::allocate_shared[abi:se190107], DB::StorageID const&, std::shared_ptr, DB::ASTCreateQuery const&, DB::ColumnsDescription const&, DB::LoadingStrictnessLevel const&, String const&, bool const&, 0>(std::allocator const&, DB::StorageID const&, std::shared_ptr&&, DB::ASTCreateQuery const&, DB::ColumnsDescription const&, DB::LoadingStrictnessLevel const&, String const&, bool const&) @ 0x0000000015e25d5c 6. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:851: std::shared_ptr std::__function::__policy_invoker (DB::StorageFactory::Arguments const&)>::__call_impl[abi:se190107] (DB::StorageFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::StorageFactory::Arguments const&) @ 0x0000000015e24a28 7. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000015d81ea2 8. /build/src/Interpreters/InterpreterCreateQuery.cpp:1945: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x00000000149009bb 9. /build/src/Interpreters/InterpreterCreateQuery.cpp:1743: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000148f9aa9 10. /build/src/Interpreters/InterpreterCreateQuery.cpp:2352: DB::InterpreterCreateQuery::execute() @ 0x0000000014905a41 11. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88dc9 12. /build/src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x0000000014c8ca7b 13. /build/src/Interpreters/DDLWorker.cpp:510: DB::DDLWorker::tryExecuteQuery(DB::DDLTaskBase&, std::shared_ptr const&, bool) @ 0x00000000144dab9e 14. /build/src/Interpreters/DDLWorker.cpp:675: DB::DDLWorker::processTask(DB::DDLTaskBase&, std::shared_ptr const&, bool) @ 0x00000000144d8ffe 15. /build/src/Databases/DatabaseReplicatedWorker.cpp:372: DB::DatabaseReplicatedDDLWorker::tryEnqueueAndExecuteEntry(DB::DDLLogEntry&, std::shared_ptr, bool) @ 0x0000000013dc29ab 16. /build/src/Databases/DatabaseReplicated.cpp:1139: DB::DatabaseReplicated::tryEnqueueReplicatedDDL(std::shared_ptr const&, std::shared_ptr, DB::QueryFlags) @ 0x0000000013d9f73c 17. /build/src/Interpreters/InterpreterCreateQuery.cpp:1723: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000148f96f8 18. /build/src/Interpreters/InterpreterCreateQuery.cpp:2352: DB::InterpreterCreateQuery::execute() @ 0x0000000014905a41 19. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88dc9 20. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 21. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 22. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 23. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 24. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 25. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 26. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 27. ? @ 0x00007fbc6213eac3 28. ? @ 0x00007fbc621d0850 2025.07.28 11:51:52.143096 [ 17207 ] {392e4d77-839b-4e8a-a49e-2f1ac48373a5} executeQuery: Code: 36. DB::Exception: Materialized view test_5.v cannot point to itself. (BAD_ARGUMENTS) (version 25.3.6.10636.altinitytest (altinity build)) (from [::1]:56256) (comment: 01527_materialized_view_stack_overflow.sql) (query 4, line 6) (in query: CREATE MATERIALIZED VIEW v to v AS SELECT c FROM t;), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x000000000a06b56b 4. /build/src/Storages/StorageMaterializedView.cpp:168: DB::StorageMaterializedView::StorageMaterializedView(DB::StorageID const&, std::shared_ptr, DB::ASTCreateQuery const&, DB::ColumnsDescription const&, DB::LoadingStrictnessLevel, String const&, bool) @ 0x0000000015e1ca9a 5. /build/contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: std::shared_ptr std::allocate_shared[abi:se190107], DB::StorageID const&, std::shared_ptr, DB::ASTCreateQuery const&, DB::ColumnsDescription const&, DB::LoadingStrictnessLevel const&, String const&, bool const&, 0>(std::allocator const&, DB::StorageID const&, std::shared_ptr&&, DB::ASTCreateQuery const&, DB::ColumnsDescription const&, DB::LoadingStrictnessLevel const&, String const&, bool const&) @ 0x0000000015e25d5c 6. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:851: std::shared_ptr std::__function::__policy_invoker (DB::StorageFactory::Arguments const&)>::__call_impl[abi:se190107] (DB::StorageFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::StorageFactory::Arguments const&) @ 0x0000000015e24a28 7. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000015d81ea2 8. /build/src/Interpreters/InterpreterCreateQuery.cpp:1945: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x00000000149009bb 9. /build/src/Interpreters/InterpreterCreateQuery.cpp:1743: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000148f9aa9 10. /build/src/Interpreters/InterpreterCreateQuery.cpp:2352: DB::InterpreterCreateQuery::execute() @ 0x0000000014905a41 11. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88dc9 12. /build/src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x0000000014c8ca7b 13. /build/src/Interpreters/DDLWorker.cpp:510: DB::DDLWorker::tryExecuteQuery(DB::DDLTaskBase&, std::shared_ptr const&, bool) @ 0x00000000144dab9e 14. /build/src/Interpreters/DDLWorker.cpp:675: DB::DDLWorker::processTask(DB::DDLTaskBase&, std::shared_ptr const&, bool) @ 0x00000000144d8ffe 15. /build/src/Databases/DatabaseReplicatedWorker.cpp:372: DB::DatabaseReplicatedDDLWorker::tryEnqueueAndExecuteEntry(DB::DDLLogEntry&, std::shared_ptr, bool) @ 0x0000000013dc29ab 16. /build/src/Databases/DatabaseReplicated.cpp:1139: DB::DatabaseReplicated::tryEnqueueReplicatedDDL(std::shared_ptr const&, std::shared_ptr, DB::QueryFlags) @ 0x0000000013d9f73c 17. /build/src/Interpreters/InterpreterCreateQuery.cpp:1723: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000148f96f8 18. /build/src/Interpreters/InterpreterCreateQuery.cpp:2352: DB::InterpreterCreateQuery::execute() @ 0x0000000014905a41 19. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88dc9 20. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 21. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 22. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 23. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 24. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 25. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 26. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 27. ? @ 0x00007fbc6213eac3 28. ? @ 0x00007fbc621d0850 2025.07.28 11:51:52.148152 [ 17207 ] {} TCPHandler: Code: 36. DB::Exception: Materialized view test_5.v cannot point to itself. (BAD_ARGUMENTS), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x000000000a06b56b 4. /build/src/Storages/StorageMaterializedView.cpp:168: DB::StorageMaterializedView::StorageMaterializedView(DB::StorageID const&, std::shared_ptr, DB::ASTCreateQuery const&, DB::ColumnsDescription const&, DB::LoadingStrictnessLevel, String const&, bool) @ 0x0000000015e1ca9a 5. /build/contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: std::shared_ptr std::allocate_shared[abi:se190107], DB::StorageID const&, std::shared_ptr, DB::ASTCreateQuery const&, DB::ColumnsDescription const&, DB::LoadingStrictnessLevel const&, String const&, bool const&, 0>(std::allocator const&, DB::StorageID const&, std::shared_ptr&&, DB::ASTCreateQuery const&, DB::ColumnsDescription const&, DB::LoadingStrictnessLevel const&, String const&, bool const&) @ 0x0000000015e25d5c 6. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:851: std::shared_ptr std::__function::__policy_invoker (DB::StorageFactory::Arguments const&)>::__call_impl[abi:se190107] (DB::StorageFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::StorageFactory::Arguments const&) @ 0x0000000015e24a28 7. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000015d81ea2 8. /build/src/Interpreters/InterpreterCreateQuery.cpp:1945: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x00000000149009bb 9. /build/src/Interpreters/InterpreterCreateQuery.cpp:1743: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000148f9aa9 10. /build/src/Interpreters/InterpreterCreateQuery.cpp:2352: DB::InterpreterCreateQuery::execute() @ 0x0000000014905a41 11. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88dc9 12. /build/src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x0000000014c8ca7b 13. /build/src/Interpreters/DDLWorker.cpp:510: DB::DDLWorker::tryExecuteQuery(DB::DDLTaskBase&, std::shared_ptr const&, bool) @ 0x00000000144dab9e 14. /build/src/Interpreters/DDLWorker.cpp:675: DB::DDLWorker::processTask(DB::DDLTaskBase&, std::shared_ptr const&, bool) @ 0x00000000144d8ffe 15. /build/src/Databases/DatabaseReplicatedWorker.cpp:372: DB::DatabaseReplicatedDDLWorker::tryEnqueueAndExecuteEntry(DB::DDLLogEntry&, std::shared_ptr, bool) @ 0x0000000013dc29ab 16. /build/src/Databases/DatabaseReplicated.cpp:1139: DB::DatabaseReplicated::tryEnqueueReplicatedDDL(std::shared_ptr const&, std::shared_ptr, DB::QueryFlags) @ 0x0000000013d9f73c 17. /build/src/Interpreters/InterpreterCreateQuery.cpp:1723: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000148f96f8 18. /build/src/Interpreters/InterpreterCreateQuery.cpp:2352: DB::InterpreterCreateQuery::execute() @ 0x0000000014905a41 19. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88dc9 20. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 21. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 22. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 23. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 24. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 25. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 26. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 27. ? @ 0x00007fbc6213eac3 28. ? @ 0x00007fbc621d0850 2025.07.28 11:51:52.379911 [ 17207 ] {0e164403-d3fc-46a1-a2ba-f10e330a5722} executeQuery: Code: 60. DB::Exception: Unknown table expression identifier 'test_5.v' in scope SELECT * FROM test_5.v. (UNKNOWN_TABLE) (version 25.3.6.10636.altinitytest (altinity build)) (from [::1]:56256) (comment: 01527_materialized_view_stack_overflow.sql) (query 5, line 7) (in query: CREATE MATERIALIZED VIEW v to t AS SELECT * FROM v;), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x000000000a6a1e2b 4. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:4372: DB::QueryAnalyzer::initializeQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000001404440b 5. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5594: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000140135fb 6. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000140127f9 7. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000014011fce 8. /build/src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000001406ce8a 9. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000014973b42 10. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000001497268d 11. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:205: DB::InterpreterSelectQueryAnalyzer::getSampleBlock(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000014973e7b 12. /build/src/Interpreters/InterpreterCreateQuery.cpp:957: DB::InterpreterCreateQuery::getTablePropertiesAndNormalizeCreateQuery(DB::ASTCreateQuery&, DB::LoadingStrictnessLevel) const @ 0x00000000148f0043 13. /build/src/Interpreters/InterpreterCreateQuery.cpp:1657: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000148f901b 14. /build/src/Interpreters/InterpreterCreateQuery.cpp:2352: DB::InterpreterCreateQuery::execute() @ 0x0000000014905a41 15. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88dc9 16. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 17. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 18. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 19. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 20. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 21. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 22. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 23. ? @ 0x00007fbc6213eac3 24. ? @ 0x00007fbc621d0850 2025.07.28 11:51:52.387295 [ 17207 ] {} TCPHandler: Code: 60. DB::Exception: Unknown table expression identifier 'test_5.v' in scope SELECT * FROM test_5.v. (UNKNOWN_TABLE), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x000000000a6a1e2b 4. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:4372: DB::QueryAnalyzer::initializeQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000001404440b 5. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5594: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000140135fb 6. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000140127f9 7. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000014011fce 8. /build/src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000001406ce8a 9. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000014973b42 10. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000001497268d 11. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:205: DB::InterpreterSelectQueryAnalyzer::getSampleBlock(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000014973e7b 12. /build/src/Interpreters/InterpreterCreateQuery.cpp:957: DB::InterpreterCreateQuery::getTablePropertiesAndNormalizeCreateQuery(DB::ASTCreateQuery&, DB::LoadingStrictnessLevel) const @ 0x00000000148f0043 13. /build/src/Interpreters/InterpreterCreateQuery.cpp:1657: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000148f901b 14. /build/src/Interpreters/InterpreterCreateQuery.cpp:2352: DB::InterpreterCreateQuery::execute() @ 0x0000000014905a41 15. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88dc9 16. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 17. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 18. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 19. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 20. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 21. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 22. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 23. ? @ 0x00007fbc6213eac3 24. ? @ 0x00007fbc621d0850 2025.07.28 11:51:52.534939 [ 3972 ] {} test_13.rmt2 (7f9b740d-015c-470e-8cc6-8ba33be0dc63): auto DB::StorageReplicatedMergeTree::processQueueEntry(ReplicatedMergeTreeQueue::SelectedEntryPtr)::(anonymous class)::operator()(LogEntryPtr &) const: Code: 86. DB::HTTPException: Received error from remote server http://146b4357c08d:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Ftest%2F01165%2Ftest_13%2Frmt%2Freplicas%2F1&part=20250728_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.6.10636.altinitytest (altinity build)) '. (RECEIVED_ERROR_FROM_REMOTE_IO_SERVER), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.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 const&, int&&, String const&, unsigned long&&, String const&) @ 0x000000000feda8d9 4. /build/src/IO/HTTPCommon.cpp:104: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x000000000feda6e2 5. /build/src/IO/HTTPCommon.cpp:93: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x000000000feda537 6. /build/src/IO/ReadWriteBufferFromHTTP.cpp:277: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x000000001184a4c4 7. /build/src/IO/ReadWriteBufferFromHTTP.cpp:285: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x000000001184a615 8. /build/src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x000000001184ae59 9. /build/src/IO/ReadWriteBufferFromHTTP.cpp:472: void std::__function::__policy_invoker::__call_impl[abi:se190107]>(std::__function::__policy_storage const*) @ 0x000000001184cedd 10. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001184858b 11. /build/src/IO/ReadWriteBufferFromHTTP.cpp:465: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x000000001184bf0b 12. /build/src/IO/ReadBuffer.h:60: DB::ReadBuffer::next() @ 0x000000000a148c7b 13. /build/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) @ 0x0000000011849fb2 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]>&)>&, 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&) @ 0x0000000011841980 15. /build/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) @ 0x000000001621208e 16. /build/src/Storages/StorageReplicatedMergeTree.cpp:5228: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl[abi:se190107] const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000015f9a5fe 17. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000015ed8bfd 18. /build/src/Storages/StorageReplicatedMergeTree.cpp:2514: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x0000000015ec9aab 19. /build/src/Storages/StorageReplicatedMergeTree.cpp:2349: DB::StorageReplicatedMergeTree::executeLogEntry(DB::ReplicatedMergeTreeLogEntry&) @ 0x0000000015eba91b 20. /build/src/Storages/StorageReplicatedMergeTree.cpp:3876: bool std::__function::__policy_invoker&)>::__call_impl[abi:se190107])::$_1, bool (std::shared_ptr&)>>(std::__function::__policy_storage const*, std::shared_ptr&) @ 0x0000000015f9837e 21. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000165d6fc3 22. /build/src/Storages/StorageReplicatedMergeTree.cpp:3872: DB::StorageReplicatedMergeTree::processQueueEntry(std::shared_ptr) @ 0x0000000015efc18a 23. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001624c1b2 24. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000162f9c70 25. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x00000000162fa55a 26. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc6653 27. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000000fccc4c3 28. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc3d92 29. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fcca080 30. ? @ 0x00007fbc6213eac3 31. ? @ 0x00007fbc621d0850 (version 25.3.6.10636.altinitytest (altinity build)) 2025.07.28 11:51:52.906764 [ 3970 ] {} test_13.rmt2 (7f9b740d-015c-470e-8cc6-8ba33be0dc63): auto DB::StorageReplicatedMergeTree::processQueueEntry(ReplicatedMergeTreeQueue::SelectedEntryPtr)::(anonymous class)::operator()(LogEntryPtr &) const: Code: 86. DB::HTTPException: Received error from remote server http://146b4357c08d:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Ftest%2F01165%2Ftest_13%2Frmt%2Freplicas%2F1&part=20250728_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.6.10636.altinitytest (altinity build)) '. (RECEIVED_ERROR_FROM_REMOTE_IO_SERVER), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.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 const&, int&&, String const&, unsigned long&&, String const&) @ 0x000000000feda8d9 4. /build/src/IO/HTTPCommon.cpp:104: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x000000000feda6e2 5. /build/src/IO/HTTPCommon.cpp:93: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x000000000feda537 6. /build/src/IO/ReadWriteBufferFromHTTP.cpp:277: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x000000001184a4c4 7. /build/src/IO/ReadWriteBufferFromHTTP.cpp:285: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x000000001184a615 8. /build/src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x000000001184ae59 9. /build/src/IO/ReadWriteBufferFromHTTP.cpp:472: void std::__function::__policy_invoker::__call_impl[abi:se190107]>(std::__function::__policy_storage const*) @ 0x000000001184cedd 10. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001184858b 11. /build/src/IO/ReadWriteBufferFromHTTP.cpp:465: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x000000001184bf0b 12. /build/src/IO/ReadBuffer.h:60: DB::ReadBuffer::next() @ 0x000000000a148c7b 13. /build/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) @ 0x0000000011849fb2 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]>&)>&, 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&) @ 0x0000000011841980 15. /build/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) @ 0x000000001621208e 16. /build/src/Storages/StorageReplicatedMergeTree.cpp:5228: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl[abi:se190107] const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000015f9a5fe 17. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000015ed8bfd 18. /build/src/Storages/StorageReplicatedMergeTree.cpp:2514: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x0000000015ec9aab 19. /build/src/Storages/StorageReplicatedMergeTree.cpp:2349: DB::StorageReplicatedMergeTree::executeLogEntry(DB::ReplicatedMergeTreeLogEntry&) @ 0x0000000015eba91b 20. /build/src/Storages/StorageReplicatedMergeTree.cpp:3876: bool std::__function::__policy_invoker&)>::__call_impl[abi:se190107])::$_1, bool (std::shared_ptr&)>>(std::__function::__policy_storage const*, std::shared_ptr&) @ 0x0000000015f9837e 21. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000165d6fc3 22. /build/src/Storages/StorageReplicatedMergeTree.cpp:3872: DB::StorageReplicatedMergeTree::processQueueEntry(std::shared_ptr) @ 0x0000000015efc18a 23. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001624c1b2 24. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000162f9c70 25. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x00000000162fa55a 26. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc6653 27. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000000fccc4c3 28. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc3d92 29. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fcca080 30. ? @ 0x00007fbc6213eac3 31. ? @ 0x00007fbc621d0850 (version 25.3.6.10636.altinitytest (altinity build)) 2025.07.28 11:51:53.058511 [ 7625 ] {01d17859-381f-4b25-916a-fdf28be2a8d4} executeQuery: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=1, jobs=1). (CANNOT_SCHEDULE_TASK) (version 25.3.6.10636.altinitytest (altinity build)) (from [::1]:47084) (comment: 03036_dynamic_read_shared_subcolumns_small.gen.sql) (query 103, line 118) (in query: select d.`Array(Array(Dynamic))`.size1, d.`Array(Array(Dynamic))`.UInt64, d.`Array(Array(Dynamic))`.`Map(String, Tuple(a UInt64))`.values.a from test order by id, d;), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000fccaeeb 4. /build/src/Common/ThreadPool.cpp:275: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000fccc813 5. /build/src/Common/ThreadPool.cpp:323: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fcc7bbc 6. /build/src/Common/ThreadPool.cpp:506: ThreadPoolImpl>::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000000fcc8c8d 7. /build/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) @ 0x00000000163f6c3a 8. /build/src/Processors/QueryPlan/ReadFromMergeTree.cpp:1810: 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) @ 0x0000000016e2b73d 9. /build/src/Processors/QueryPlan/ReadFromMergeTree.cpp:1516: DB::ReadFromMergeTree::selectRangesToRead(std::vector, std::allocator>>, bool) const @ 0x0000000016e2a679 10. /build/src/Processors/QueryPlan/ReadFromMergeTree.cpp:1511: DB::ReadFromMergeTree::selectRangesToRead(bool) const @ 0x0000000016e2a472 11. /build/src/Processors/QueryPlan/ReadFromMergeTree.cpp:1998: DB::ReadFromMergeTree::initializePipeline(DB::QueryPipelineBuilder&, DB::BuildQueryPipelineSettings const&) @ 0x0000000016e3248c 12. /build/src/Processors/QueryPlan/ISourceStep.cpp:20: DB::ISourceStep::updatePipeline(std::vector>, std::allocator>>>, DB::BuildQueryPipelineSettings const&) @ 0x0000000016dd18d0 13. /build/src/Processors/QueryPlan/QueryPlan.cpp:201: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x0000000016e0076f 14. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:275: DB::InterpreterSelectQueryAnalyzer::buildQueryPipeline() @ 0x0000000014974614 15. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:242: DB::InterpreterSelectQueryAnalyzer::execute() @ 0x000000001497439e 16. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88dc9 17. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 18. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 19. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 20. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 21. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 22. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 23. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 24. ? @ 0x00007fbc6213eac3 25. ? @ 0x00007fbc621d0850 2025.07.28 11:51:53.080540 [ 7625 ] {} 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. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000fccaeeb 4. /build/src/Common/ThreadPool.cpp:275: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000fccc813 5. /build/src/Common/ThreadPool.cpp:323: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fcc7bbc 6. /build/src/Common/ThreadPool.cpp:506: ThreadPoolImpl>::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000000fcc8c8d 7. /build/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) @ 0x00000000163f6c3a 8. /build/src/Processors/QueryPlan/ReadFromMergeTree.cpp:1810: 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) @ 0x0000000016e2b73d 9. /build/src/Processors/QueryPlan/ReadFromMergeTree.cpp:1516: DB::ReadFromMergeTree::selectRangesToRead(std::vector, std::allocator>>, bool) const @ 0x0000000016e2a679 10. /build/src/Processors/QueryPlan/ReadFromMergeTree.cpp:1511: DB::ReadFromMergeTree::selectRangesToRead(bool) const @ 0x0000000016e2a472 11. /build/src/Processors/QueryPlan/ReadFromMergeTree.cpp:1998: DB::ReadFromMergeTree::initializePipeline(DB::QueryPipelineBuilder&, DB::BuildQueryPipelineSettings const&) @ 0x0000000016e3248c 12. /build/src/Processors/QueryPlan/ISourceStep.cpp:20: DB::ISourceStep::updatePipeline(std::vector>, std::allocator>>>, DB::BuildQueryPipelineSettings const&) @ 0x0000000016dd18d0 13. /build/src/Processors/QueryPlan/QueryPlan.cpp:201: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x0000000016e0076f 14. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:275: DB::InterpreterSelectQueryAnalyzer::buildQueryPipeline() @ 0x0000000014974614 15. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:242: DB::InterpreterSelectQueryAnalyzer::execute() @ 0x000000001497439e 16. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88dc9 17. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 18. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 19. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 20. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 21. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 22. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 23. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 24. ? @ 0x00007fbc6213eac3 25. ? @ 0x00007fbc621d0850 2025.07.28 11:51:54.049360 [ 17208 ] {8089b22a-3209-42e9-9a6d-9e3beb43eb74} 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 'a' by first 1 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.6.10636.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. (CANNOT_EXTRACT_TABLE_STRUCTURE) (version 25.3.6.10636.altinitytest (altinity build)) (from [::1]:60510) (comment: 02783_max_bytes_to_read_in_schema_inference.sql) (query 3, line 3) (in query: desc format('JSONEachRow', '{"a" : null}, {"a" : 42}') settings input_format_max_bytes_to_read_for_schema_inference=10;), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&, String&) @ 0x000000000e65d7ab 4. /build/src/Formats/ReadSchemaUtils.cpp:487: DB::readSchemaFromFormatImpl(std::optional, std::optional const&, DB::IReadBufferIterator&, std::shared_ptr const&) @ 0x000000001697986d 5. /build/src/Formats/ReadSchemaUtils.cpp:548: DB::readSchemaFromFormat(String const&, std::optional const&, DB::IReadBufferIterator&, std::shared_ptr const&) @ 0x000000001697a742 6. /build/src/TableFunctions/TableFunctionFormat.cpp:97: DB::(anonymous namespace)::TableFunctionFormat::getActualTableStructure(std::shared_ptr, bool) const @ 0x0000000011859101 7. /build/src/Interpreters/InterpreterDescribeQuery.cpp:159: DB::InterpreterDescribeQuery::fillColumnsFromTableFunction(DB::ASTTableExpression const&) @ 0x0000000014cddb51 8. /build/src/Interpreters/InterpreterDescribeQuery.cpp:102: DB::InterpreterDescribeQuery::execute() @ 0x0000000014cdce78 9. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88dc9 10. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 11. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 12. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 13. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 14. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 16. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 17. ? @ 0x00007fbc6213eac3 18. ? @ 0x00007fbc621d0850 2025.07.28 11:51:54.054101 [ 17208 ] {} 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 'a' by first 1 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.6.10636.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. (CANNOT_EXTRACT_TABLE_STRUCTURE), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&, String&) @ 0x000000000e65d7ab 4. /build/src/Formats/ReadSchemaUtils.cpp:487: DB::readSchemaFromFormatImpl(std::optional, std::optional const&, DB::IReadBufferIterator&, std::shared_ptr const&) @ 0x000000001697986d 5. /build/src/Formats/ReadSchemaUtils.cpp:548: DB::readSchemaFromFormat(String const&, std::optional const&, DB::IReadBufferIterator&, std::shared_ptr const&) @ 0x000000001697a742 6. /build/src/TableFunctions/TableFunctionFormat.cpp:97: DB::(anonymous namespace)::TableFunctionFormat::getActualTableStructure(std::shared_ptr, bool) const @ 0x0000000011859101 7. /build/src/Interpreters/InterpreterDescribeQuery.cpp:159: DB::InterpreterDescribeQuery::fillColumnsFromTableFunction(DB::ASTTableExpression const&) @ 0x0000000014cddb51 8. /build/src/Interpreters/InterpreterDescribeQuery.cpp:102: DB::InterpreterDescribeQuery::execute() @ 0x0000000014cdce78 9. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88dc9 10. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 11. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 12. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 13. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 14. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 16. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 17. ? @ 0x00007fbc6213eac3 18. ? @ 0x00007fbc621d0850 2025.07.28 11:51:54.110847 [ 3964 ] {} test_13.rmt2 (7f9b740d-015c-470e-8cc6-8ba33be0dc63): auto DB::StorageReplicatedMergeTree::processQueueEntry(ReplicatedMergeTreeQueue::SelectedEntryPtr)::(anonymous class)::operator()(LogEntryPtr &) const: Code: 86. DB::HTTPException: Received error from remote server http://146b4357c08d:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Ftest%2F01165%2Ftest_13%2Frmt%2Freplicas%2F1&part=20250728_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.6.10636.altinitytest (altinity build)) '. (RECEIVED_ERROR_FROM_REMOTE_IO_SERVER), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.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 const&, int&&, String const&, unsigned long&&, String const&) @ 0x000000000feda8d9 4. /build/src/IO/HTTPCommon.cpp:104: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x000000000feda6e2 5. /build/src/IO/HTTPCommon.cpp:93: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x000000000feda537 6. /build/src/IO/ReadWriteBufferFromHTTP.cpp:277: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x000000001184a4c4 7. /build/src/IO/ReadWriteBufferFromHTTP.cpp:285: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x000000001184a615 8. /build/src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x000000001184ae59 9. /build/src/IO/ReadWriteBufferFromHTTP.cpp:472: void std::__function::__policy_invoker::__call_impl[abi:se190107]>(std::__function::__policy_storage const*) @ 0x000000001184cedd 10. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001184858b 11. /build/src/IO/ReadWriteBufferFromHTTP.cpp:465: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x000000001184bf0b 12. /build/src/IO/ReadBuffer.h:60: DB::ReadBuffer::next() @ 0x000000000a148c7b 13. /build/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) @ 0x0000000011849fb2 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]>&)>&, 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&) @ 0x0000000011841980 15. /build/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) @ 0x000000001621208e 16. /build/src/Storages/StorageReplicatedMergeTree.cpp:5228: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl[abi:se190107] const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000015f9a5fe 17. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000015ed8bfd 18. /build/src/Storages/StorageReplicatedMergeTree.cpp:2514: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x0000000015ec9aab 19. /build/src/Storages/StorageReplicatedMergeTree.cpp:2349: DB::StorageReplicatedMergeTree::executeLogEntry(DB::ReplicatedMergeTreeLogEntry&) @ 0x0000000015eba91b 20. /build/src/Storages/StorageReplicatedMergeTree.cpp:3876: bool std::__function::__policy_invoker&)>::__call_impl[abi:se190107])::$_1, bool (std::shared_ptr&)>>(std::__function::__policy_storage const*, std::shared_ptr&) @ 0x0000000015f9837e 21. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000165d6fc3 22. /build/src/Storages/StorageReplicatedMergeTree.cpp:3872: DB::StorageReplicatedMergeTree::processQueueEntry(std::shared_ptr) @ 0x0000000015efc18a 23. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001624c1b2 24. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000162f9c70 25. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x00000000162fa55a 26. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc6653 27. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000000fccc4c3 28. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc3d92 29. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fcca080 30. ? @ 0x00007fbc6213eac3 31. ? @ 0x00007fbc621d0850 (version 25.3.6.10636.altinitytest (altinity build)) 2025.07.28 11:51:54.759399 [ 3966 ] {} test_13.rmt2 (7f9b740d-015c-470e-8cc6-8ba33be0dc63): auto DB::StorageReplicatedMergeTree::processQueueEntry(ReplicatedMergeTreeQueue::SelectedEntryPtr)::(anonymous class)::operator()(LogEntryPtr &) const: Code: 86. DB::HTTPException: Received error from remote server http://146b4357c08d:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Ftest%2F01165%2Ftest_13%2Frmt%2Freplicas%2F1&part=20250728_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.6.10636.altinitytest (altinity build)) '. (RECEIVED_ERROR_FROM_REMOTE_IO_SERVER), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.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 const&, int&&, String const&, unsigned long&&, String const&) @ 0x000000000feda8d9 4. /build/src/IO/HTTPCommon.cpp:104: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x000000000feda6e2 5. /build/src/IO/HTTPCommon.cpp:93: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x000000000feda537 6. /build/src/IO/ReadWriteBufferFromHTTP.cpp:277: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x000000001184a4c4 7. /build/src/IO/ReadWriteBufferFromHTTP.cpp:285: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x000000001184a615 8. /build/src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x000000001184ae59 9. /build/src/IO/ReadWriteBufferFromHTTP.cpp:472: void std::__function::__policy_invoker::__call_impl[abi:se190107]>(std::__function::__policy_storage const*) @ 0x000000001184cedd 10. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001184858b 11. /build/src/IO/ReadWriteBufferFromHTTP.cpp:465: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x000000001184bf0b 12. /build/src/IO/ReadBuffer.h:60: DB::ReadBuffer::next() @ 0x000000000a148c7b 13. /build/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) @ 0x0000000011849fb2 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]>&)>&, 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&) @ 0x0000000011841980 15. /build/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) @ 0x000000001621208e 16. /build/src/Storages/StorageReplicatedMergeTree.cpp:5228: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl[abi:se190107] const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000015f9a5fe 17. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000015ed8bfd 18. /build/src/Storages/StorageReplicatedMergeTree.cpp:2514: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x0000000015ec9aab 19. /build/src/Storages/StorageReplicatedMergeTree.cpp:2349: DB::StorageReplicatedMergeTree::executeLogEntry(DB::ReplicatedMergeTreeLogEntry&) @ 0x0000000015eba91b 20. /build/src/Storages/StorageReplicatedMergeTree.cpp:3876: bool std::__function::__policy_invoker&)>::__call_impl[abi:se190107])::$_1, bool (std::shared_ptr&)>>(std::__function::__policy_storage const*, std::shared_ptr&) @ 0x0000000015f9837e 21. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000165d6fc3 22. /build/src/Storages/StorageReplicatedMergeTree.cpp:3872: DB::StorageReplicatedMergeTree::processQueueEntry(std::shared_ptr) @ 0x0000000015efc18a 23. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001624c1b2 24. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000162f9c70 25. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x00000000162fa55a 26. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc6653 27. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000000fccc4c3 28. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc3d92 29. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fcca080 30. ? @ 0x00007fbc6213eac3 31. ? @ 0x00007fbc621d0850 (version 25.3.6.10636.altinitytest (altinity build)) 2025.07.28 11:51:54.919906 [ 17256 ] {2e805130-7ed9-41e6-9b6c-c2da7e4a61bc} executeQuery: Code: 48. DB::Exception: Alter of type 'COMMENT_COLUMN' is not supported by storage Dictionary. (NOT_IMPLEMENTED) (version 25.3.6.10636.altinitytest (altinity build)) (from [::1]:60480) (comment: 02155_dictionary_comment.sql) (query 7, line 22) (in query: ALTER TABLE 02155_test_dictionary COMMENT COLUMN value 'value_column';), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, DB::AlterCommand::Type const&, String&&) @ 0x00000000134653eb 4. /build/src/Storages/StorageDictionary.cpp:303: DB::StorageDictionary::checkAlterIsPossible(DB::AlterCommands const&, std::shared_ptr) const @ 0x0000000015d59ddc 5. /build/src/Interpreters/InterpreterAlterQuery.cpp:215: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x00000000148deab3 6. /build/src/Interpreters/InterpreterAlterQuery.cpp:77: DB::InterpreterAlterQuery::execute() @ 0x00000000148dcb0d 7. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88dc9 8. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 9. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 10. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 11. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 12. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 13. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 14. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 15. ? @ 0x00007fbc6213eac3 16. ? @ 0x00007fbc621d0850 2025.07.28 11:51:54.923921 [ 17256 ] {} TCPHandler: Code: 48. DB::Exception: Alter of type 'COMMENT_COLUMN' is not supported by storage Dictionary. (NOT_IMPLEMENTED), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, DB::AlterCommand::Type const&, String&&) @ 0x00000000134653eb 4. /build/src/Storages/StorageDictionary.cpp:303: DB::StorageDictionary::checkAlterIsPossible(DB::AlterCommands const&, std::shared_ptr) const @ 0x0000000015d59ddc 5. /build/src/Interpreters/InterpreterAlterQuery.cpp:215: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x00000000148deab3 6. /build/src/Interpreters/InterpreterAlterQuery.cpp:77: DB::InterpreterAlterQuery::execute() @ 0x00000000148dcb0d 7. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88dc9 8. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 9. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 10. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 11. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 12. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 13. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 14. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 15. ? @ 0x00007fbc6213eac3 16. ? @ 0x00007fbc621d0850 2025.07.28 11:51:55.447728 [ 3972 ] {} test_13.rmt2 (7f9b740d-015c-470e-8cc6-8ba33be0dc63): auto DB::StorageReplicatedMergeTree::processQueueEntry(ReplicatedMergeTreeQueue::SelectedEntryPtr)::(anonymous class)::operator()(LogEntryPtr &) const: Code: 86. DB::HTTPException: Received error from remote server http://146b4357c08d:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Ftest%2F01165%2Ftest_13%2Frmt%2Freplicas%2F1&part=20250728_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.6.10636.altinitytest (altinity build)) '. (RECEIVED_ERROR_FROM_REMOTE_IO_SERVER), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.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 const&, int&&, String const&, unsigned long&&, String const&) @ 0x000000000feda8d9 4. /build/src/IO/HTTPCommon.cpp:104: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x000000000feda6e2 5. /build/src/IO/HTTPCommon.cpp:93: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x000000000feda537 6. /build/src/IO/ReadWriteBufferFromHTTP.cpp:277: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x000000001184a4c4 7. /build/src/IO/ReadWriteBufferFromHTTP.cpp:285: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x000000001184a615 8. /build/src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x000000001184ae59 9. /build/src/IO/ReadWriteBufferFromHTTP.cpp:472: void std::__function::__policy_invoker::__call_impl[abi:se190107]>(std::__function::__policy_storage const*) @ 0x000000001184cedd 10. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001184858b 11. /build/src/IO/ReadWriteBufferFromHTTP.cpp:465: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x000000001184bf0b 12. /build/src/IO/ReadBuffer.h:60: DB::ReadBuffer::next() @ 0x000000000a148c7b 13. /build/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) @ 0x0000000011849fb2 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]>&)>&, 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&) @ 0x0000000011841980 15. /build/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) @ 0x000000001621208e 16. /build/src/Storages/StorageReplicatedMergeTree.cpp:5228: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl[abi:se190107] const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000015f9a5fe 17. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000015ed8bfd 18. /build/src/Storages/StorageReplicatedMergeTree.cpp:2514: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x0000000015ec9aab 19. /build/src/Storages/StorageReplicatedMergeTree.cpp:2349: DB::StorageReplicatedMergeTree::executeLogEntry(DB::ReplicatedMergeTreeLogEntry&) @ 0x0000000015eba91b 20. /build/src/Storages/StorageReplicatedMergeTree.cpp:3876: bool std::__function::__policy_invoker&)>::__call_impl[abi:se190107])::$_1, bool (std::shared_ptr&)>>(std::__function::__policy_storage const*, std::shared_ptr&) @ 0x0000000015f9837e 21. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000165d6fc3 22. /build/src/Storages/StorageReplicatedMergeTree.cpp:3872: DB::StorageReplicatedMergeTree::processQueueEntry(std::shared_ptr) @ 0x0000000015efc18a 23. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001624c1b2 24. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000162f9c70 25. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x00000000162fa55a 26. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc6653 27. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000000fccc4c3 28. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc3d92 29. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fcca080 30. ? @ 0x00007fbc6213eac3 31. ? @ 0x00007fbc621d0850 (version 25.3.6.10636.altinitytest (altinity build)) 2025.07.28 11:51:55.783798 [ 12454 ] {2c16eff2-33c1-4434-9eb7-a860af413215} executeQuery: Code: 241. DB::Exception: Query memory tracker: fault injected. Would use 1.09 MiB (attempt to allocate chunk of 1.09 MiB), maximum: 9.31 GiB. (MEMORY_LIMIT_EXCEEDED) (version 25.3.6.10636.altinitytest (altinity build)) (from [::ffff:127.0.0.1]:49446) (comment: 01213_alter_rename_with_default_zookeeper_long.sql) (query 18, line 55) (in query: SELECT `__table1`.`renamed_date1` AS `renamed_date1`, `__table1`.`date2` AS `date2`, `__table1`.`value1` AS `value1`, `__table1`.`value2` AS `value2` FROM `test_a3lzqg6f`.`table_rename_with_ttl` AS `__table1` WHERE `__table1`.`value1` = '1'), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.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&&) @ 0x000000000fc1a9d9 4. /build/src/Common/MemoryTracker.cpp:298: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000000fc19854 5. /build/src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000000fc19293 6. /build/src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000000fb80c54 7. /build/src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000000fb7f3c4 8. /build/src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000000fc687b2 9. /build/src/IO/BufferWithOwnMemory.h:47: DB::CompressedWriteBuffer::CompressedWriteBuffer(DB::WriteBuffer&, std::shared_ptr, unsigned long, bool, unsigned long) @ 0x0000000017939c8a 10. /build/contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: DB::TCPHandler::initBlockOutput(DB::QueryState&, DB::Block const&) @ 0x00000000168fbff2 11. /build/src/Server/TCPHandler.cpp:2446: DB::TCPHandler::sendData(DB::QueryState&, DB::Block const&) @ 0x00000000168fa07c 12. /build/src/Server/TCPHandler.cpp:1225: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x00000000168f1409 13. /build/src/Server/TCPHandler.cpp:678: DB::TCPHandler::runImpl() @ 0x00000000168e68e5 14. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 15. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 16. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 17. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 18. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 19. ? @ 0x00007fbc6213eac3 20. ? @ 0x00007fbc621d0850 2025.07.28 11:51:55.805808 [ 12454 ] {} TCPHandler: Code: 241. DB::Exception: Query memory tracker: fault injected. Would use 1.09 MiB (attempt to allocate chunk of 1.09 MiB), maximum: 9.31 GiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.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&&) @ 0x000000000fc1a9d9 4. /build/src/Common/MemoryTracker.cpp:298: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000000fc19854 5. /build/src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000000fc19293 6. /build/src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000000fb80c54 7. /build/src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000000fb7f3c4 8. /build/src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000000fc687b2 9. /build/src/IO/BufferWithOwnMemory.h:47: DB::CompressedWriteBuffer::CompressedWriteBuffer(DB::WriteBuffer&, std::shared_ptr, unsigned long, bool, unsigned long) @ 0x0000000017939c8a 10. /build/contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: DB::TCPHandler::initBlockOutput(DB::QueryState&, DB::Block const&) @ 0x00000000168fbff2 11. /build/src/Server/TCPHandler.cpp:2446: DB::TCPHandler::sendData(DB::QueryState&, DB::Block const&) @ 0x00000000168fa07c 12. /build/src/Server/TCPHandler.cpp:1225: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x00000000168f1409 13. /build/src/Server/TCPHandler.cpp:678: DB::TCPHandler::runImpl() @ 0x00000000168e68e5 14. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 15. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 16. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 17. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 18. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 19. ? @ 0x00007fbc6213eac3 20. ? @ 0x00007fbc621d0850 2025.07.28 11:51:55.830374 [ 17958 ] {56d345aa-4f6b-4b85-85b6-be36230ac523} executeQuery: Code: 241. DB::Exception: Received from 127.0.0.8:9000. DB::Exception: Query memory tracker: fault injected. Would use 1.09 MiB (attempt to allocate chunk of 1.09 MiB), maximum: 9.31 GiB. Stack trace: 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.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&&) @ 0x000000000fc1a9d9 4. /build/src/Common/MemoryTracker.cpp:298: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000000fc19854 5. /build/src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000000fc19293 6. /build/src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000000fb80c54 7. /build/src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000000fb7f3c4 8. /build/src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000000fc687b2 9. /build/src/IO/BufferWithOwnMemory.h:47: DB::CompressedWriteBuffer::CompressedWriteBuffer(DB::WriteBuffer&, std::shared_ptr, unsigned long, bool, unsigned long) @ 0x0000000017939c8a 10. /build/contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: DB::TCPHandler::initBlockOutput(DB::QueryState&, DB::Block const&) @ 0x00000000168fbff2 11. /build/src/Server/TCPHandler.cpp:2446: DB::TCPHandler::sendData(DB::QueryState&, DB::Block const&) @ 0x00000000168fa07c 12. /build/src/Server/TCPHandler.cpp:1225: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x00000000168f1409 13. /build/src/Server/TCPHandler.cpp:678: DB::TCPHandler::runImpl() @ 0x00000000168e68e5 14. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 15. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 16. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 17. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 18. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 19. ? @ 0x00007fbc6213eac3 20. ? @ 0x00007fbc621d0850 : While executing Remote. (MEMORY_LIMIT_EXCEEDED) (version 25.3.6.10636.altinitytest (altinity build)) (from [::1]:56040) (comment: 01213_alter_rename_with_default_zookeeper_long.sql) (query 18, line 55) (in query: SELECT * FROM table_rename_with_ttl WHERE value1 = '1' FORMAT TSVWithNames;), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:111: DB::readException(DB::ReadBuffer&, String const&, bool) @ 0x000000000fc6e157 3. /build/src/Client/Connection.cpp:1445: DB::Connection::receiveException() const @ 0x00000000167d4127 4. /build/src/Client/Connection.cpp:1274: DB::Connection::receivePacket() @ 0x00000000167db312 5. /build/src/Client/MultiplexedConnections.cpp:380: DB::MultiplexedConnections::receivePacketUnlocked(std::function) @ 0x00000000168163a9 6. /build/src/QueryPipeline/RemoteQueryExecutorReadContext.cpp:67: DB::RemoteQueryExecutorReadContext::Task::run(std::function, std::function) @ 0x0000000013bd23fe 7. /build/src/Common/AsyncTaskExecutor.cpp:89: DB::AsyncTaskExecutor::Routine::operator()(std::function) @ 0x0000000013bd1892 8. /build/src/Common/Fiber.h:76: boost::context::detail::fiber_record>::run(void*) @ 0x0000000013bd16fa 9. /build/contrib/boost/boost/context/fiber_fcontext.hpp:97: void boost::context::detail::fiber_entry>>(boost::context::detail::transfer_t) @ 0x0000000013bd1621 2025.07.28 11:51:55.849284 [ 17958 ] {} TCPHandler: Code: 241. DB::Exception: Received from 127.0.0.8:9000. DB::Exception: Query memory tracker: fault injected. Would use 1.09 MiB (attempt to allocate chunk of 1.09 MiB), maximum: 9.31 GiB. Stack trace: 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.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&&) @ 0x000000000fc1a9d9 4. /build/src/Common/MemoryTracker.cpp:298: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000000fc19854 5. /build/src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000000fc19293 6. /build/src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000000fb80c54 7. /build/src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000000fb7f3c4 8. /build/src/IO/BufferWithOwnMemory.h:127: DB::Memory>::alloc(unsigned long) @ 0x000000000fc687b2 9. /build/src/IO/BufferWithOwnMemory.h:47: DB::CompressedWriteBuffer::CompressedWriteBuffer(DB::WriteBuffer&, std::shared_ptr, unsigned long, bool, unsigned long) @ 0x0000000017939c8a 10. /build/contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: DB::TCPHandler::initBlockOutput(DB::QueryState&, DB::Block const&) @ 0x00000000168fbff2 11. /build/src/Server/TCPHandler.cpp:2446: DB::TCPHandler::sendData(DB::QueryState&, DB::Block const&) @ 0x00000000168fa07c 12. /build/src/Server/TCPHandler.cpp:1225: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x00000000168f1409 13. /build/src/Server/TCPHandler.cpp:678: DB::TCPHandler::runImpl() @ 0x00000000168e68e5 14. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 15. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 16. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 17. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 18. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 19. ? @ 0x00007fbc6213eac3 20. ? @ 0x00007fbc621d0850 : While executing Remote. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:111: DB::readException(DB::ReadBuffer&, String const&, bool) @ 0x000000000fc6e157 3. /build/src/Client/Connection.cpp:1445: DB::Connection::receiveException() const @ 0x00000000167d4127 4. /build/src/Client/Connection.cpp:1274: DB::Connection::receivePacket() @ 0x00000000167db312 5. /build/src/Client/MultiplexedConnections.cpp:380: DB::MultiplexedConnections::receivePacketUnlocked(std::function) @ 0x00000000168163a9 6. /build/src/QueryPipeline/RemoteQueryExecutorReadContext.cpp:67: DB::RemoteQueryExecutorReadContext::Task::run(std::function, std::function) @ 0x0000000013bd23fe 7. /build/src/Common/AsyncTaskExecutor.cpp:89: DB::AsyncTaskExecutor::Routine::operator()(std::function) @ 0x0000000013bd1892 8. /build/src/Common/Fiber.h:76: boost::context::detail::fiber_record>::run(void*) @ 0x0000000013bd16fa 9. /build/contrib/boost/boost/context/fiber_fcontext.hpp:97: void boost::context::detail::fiber_entry>>(boost::context::detail::transfer_t) @ 0x0000000013bd1621 Job's origin stack trace: 0. /build/src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000000fc33b84 1. /build/src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000000fcc2ea7 2. /build/src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fcc535c 3. /build/src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000000fcc584d 4. /build/src/Common/ThreadPool.h:279: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x00000000169bf193 5. /build/src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x00000000169bf518 6. /build/src/Server/TCPHandler.cpp:1237: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x00000000168f1525 7. /build/src/Server/TCPHandler.cpp:678: DB::TCPHandler::runImpl() @ 0x00000000168e68e5 8. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 9. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 10. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 11. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 12. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 13. ? @ 0x00007fbc6213eac3 14. ? @ 0x00007fbc621d0850 2025.07.28 11:51:55.898946 [ 3971 ] {} test_13.rmt2 (7f9b740d-015c-470e-8cc6-8ba33be0dc63): auto DB::StorageReplicatedMergeTree::processQueueEntry(ReplicatedMergeTreeQueue::SelectedEntryPtr)::(anonymous class)::operator()(LogEntryPtr &) const: Code: 86. DB::HTTPException: Received error from remote server http://146b4357c08d:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Ftest%2F01165%2Ftest_13%2Frmt%2Freplicas%2F1&part=20250728_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.6.10636.altinitytest (altinity build)) '. (RECEIVED_ERROR_FROM_REMOTE_IO_SERVER), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.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 const&, int&&, String const&, unsigned long&&, String const&) @ 0x000000000feda8d9 4. /build/src/IO/HTTPCommon.cpp:104: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x000000000feda6e2 5. /build/src/IO/HTTPCommon.cpp:93: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x000000000feda537 6. /build/src/IO/ReadWriteBufferFromHTTP.cpp:277: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x000000001184a4c4 7. /build/src/IO/ReadWriteBufferFromHTTP.cpp:285: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x000000001184a615 8. /build/src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x000000001184ae59 9. /build/src/IO/ReadWriteBufferFromHTTP.cpp:472: void std::__function::__policy_invoker::__call_impl[abi:se190107]>(std::__function::__policy_storage const*) @ 0x000000001184cedd 10. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001184858b 11. /build/src/IO/ReadWriteBufferFromHTTP.cpp:465: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x000000001184bf0b 12. /build/src/IO/ReadBuffer.h:60: DB::ReadBuffer::next() @ 0x000000000a148c7b 13. /build/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) @ 0x0000000011849fb2 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]>&)>&, 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&) @ 0x0000000011841980 15. /build/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) @ 0x000000001621208e 16. /build/src/Storages/StorageReplicatedMergeTree.cpp:5228: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl[abi:se190107] const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000015f9a5fe 17. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000015ed8bfd 18. /build/src/Storages/StorageReplicatedMergeTree.cpp:2514: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x0000000015ec9aab 19. /build/src/Storages/StorageReplicatedMergeTree.cpp:2349: DB::StorageReplicatedMergeTree::executeLogEntry(DB::ReplicatedMergeTreeLogEntry&) @ 0x0000000015eba91b 20. /build/src/Storages/StorageReplicatedMergeTree.cpp:3876: bool std::__function::__policy_invoker&)>::__call_impl[abi:se190107])::$_1, bool (std::shared_ptr&)>>(std::__function::__policy_storage const*, std::shared_ptr&) @ 0x0000000015f9837e 21. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000165d6fc3 22. /build/src/Storages/StorageReplicatedMergeTree.cpp:3872: DB::StorageReplicatedMergeTree::processQueueEntry(std::shared_ptr) @ 0x0000000015efc18a 23. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001624c1b2 24. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000162f9c70 25. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x00000000162fa55a 26. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc6653 27. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000000fccc4c3 28. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc3d92 29. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fcca080 30. ? @ 0x00007fbc6213eac3 31. ? @ 0x00007fbc621d0850 (version 25.3.6.10636.altinitytest (altinity build)) 2025.07.28 11:51:56.314584 [ 3977 ] {} test_13.rmt2 (7f9b740d-015c-470e-8cc6-8ba33be0dc63): auto DB::StorageReplicatedMergeTree::processQueueEntry(ReplicatedMergeTreeQueue::SelectedEntryPtr)::(anonymous class)::operator()(LogEntryPtr &) const: Code: 86. DB::HTTPException: Received error from remote server http://146b4357c08d:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Ftest%2F01165%2Ftest_13%2Frmt%2Freplicas%2F1&part=20250728_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.6.10636.altinitytest (altinity build)) '. (RECEIVED_ERROR_FROM_REMOTE_IO_SERVER), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.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 const&, int&&, String const&, unsigned long&&, String const&) @ 0x000000000feda8d9 4. /build/src/IO/HTTPCommon.cpp:104: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x000000000feda6e2 5. /build/src/IO/HTTPCommon.cpp:93: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x000000000feda537 6. /build/src/IO/ReadWriteBufferFromHTTP.cpp:277: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x000000001184a4c4 7. /build/src/IO/ReadWriteBufferFromHTTP.cpp:285: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x000000001184a615 8. /build/src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x000000001184ae59 9. /build/src/IO/ReadWriteBufferFromHTTP.cpp:472: void std::__function::__policy_invoker::__call_impl[abi:se190107]>(std::__function::__policy_storage const*) @ 0x000000001184cedd 10. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001184858b 11. /build/src/IO/ReadWriteBufferFromHTTP.cpp:465: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x000000001184bf0b 12. /build/src/IO/ReadBuffer.h:60: DB::ReadBuffer::next() @ 0x000000000a148c7b 13. /build/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) @ 0x0000000011849fb2 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]>&)>&, 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&) @ 0x0000000011841980 15. /build/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) @ 0x000000001621208e 16. /build/src/Storages/StorageReplicatedMergeTree.cpp:5228: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl[abi:se190107] const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000015f9a5fe 17. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000015ed8bfd 18. /build/src/Storages/StorageReplicatedMergeTree.cpp:2514: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x0000000015ec9aab 19. /build/src/Storages/StorageReplicatedMergeTree.cpp:2349: DB::StorageReplicatedMergeTree::executeLogEntry(DB::ReplicatedMergeTreeLogEntry&) @ 0x0000000015eba91b 20. /build/src/Storages/StorageReplicatedMergeTree.cpp:3876: bool std::__function::__policy_invoker&)>::__call_impl[abi:se190107])::$_1, bool (std::shared_ptr&)>>(std::__function::__policy_storage const*, std::shared_ptr&) @ 0x0000000015f9837e 21. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000165d6fc3 22. /build/src/Storages/StorageReplicatedMergeTree.cpp:3872: DB::StorageReplicatedMergeTree::processQueueEntry(std::shared_ptr) @ 0x0000000015efc18a 23. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001624c1b2 24. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000162f9c70 25. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x00000000162fa55a 26. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc6653 27. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000000fccc4c3 28. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc3d92 29. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fcca080 30. ? @ 0x00007fbc6213eac3 31. ? @ 0x00007fbc621d0850 (version 25.3.6.10636.altinitytest (altinity build)) 2025.07.28 11:51:56.369212 [ 17287 ] {c9b230b2-8b87-44b8-a1d7-410510ae5cb8} executeQuery: Code: 439. DB::Exception: Cannot schedule a task: failed to start the thread (threads=0, jobs=0). (CANNOT_SCHEDULE_TASK) (version 25.3.6.10636.altinitytest (altinity build)) (from [::1]:60646) (comment: 02451_order_by_monotonic.sh) (query 1, line 1) (in query: CREATE TABLE t_order_by_monotonic (`a` Int64, `b` Int64) ENGINE = MergeTree ORDER BY (a, b) SETTINGS index_granularity = 19571, min_bytes_for_wide_part = 0, ratio_of_defaults_for_sparse_serialization = 0., replace_long_file_name_to_hash = false, max_file_name_length = 44, min_bytes_for_full_part_storage = 480027662, compact_parts_max_bytes_to_buffer = 32299598, compact_parts_max_granules_to_buffer = 1, compact_parts_merge_max_bytes_to_prefetch_part = 10506231, merge_max_block_size = 17845, old_parts_lifetime = 12., 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 = 6168929447, index_granularity_bytes = 26936069, use_const_adaptive_granularity = false, enable_index_granularity_compression = false, concurrent_part_removal_threshold = 4, 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 = 63684, primary_key_compress_block_size = 39670, 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. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000fccaeeb 4. /build/src/Common/ThreadPool.cpp:275: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000fccc813 5. /build/src/Common/ThreadPool.cpp:308: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fcc8286 6. /build/src/Common/ThreadPool.cpp:494: ThreadPoolImpl>::scheduleOrThrowOnError(std::function, Priority) @ 0x000000000fcc7a0e 7. /build/src/Common/threadPoolCallbackRunner.h:188: DB::ThreadPoolCallbackRunnerLocal>, std::function>::operator()(std::function&&, Priority, std::optional) @ 0x00000000119df78e 8. /build/src/Storages/MergeTree/MergeTreeData.cpp:1923: DB::MergeTreeData::loadDataParts(bool, std::optional, std::equal_to, std::allocator>>) @ 0x0000000016314fbd 9. /build/src/Storages/StorageMergeTree.cpp:161: 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>) @ 0x0000000016632c15 10. /build/contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: std::shared_ptr std::allocate_shared[abi:se190107], 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>&&) @ 0x00000000166326f0 11. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:851: DB::create(DB::StorageFactory::Arguments const&) @ 0x000000001662f01d 12. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000015d81ea2 13. /build/src/Interpreters/InterpreterCreateQuery.cpp:1945: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x00000000149009bb 14. /build/src/Interpreters/InterpreterCreateQuery.cpp:1743: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000148f9aa9 15. /build/src/Interpreters/InterpreterCreateQuery.cpp:2352: DB::InterpreterCreateQuery::execute() @ 0x0000000014905a41 16. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88dc9 17. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 18. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 19. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 20. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 21. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 22. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 23. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 24. ? @ 0x00007fbc6213eac3 25. ? @ 0x00007fbc621d0850 2025.07.28 11:51:56.392136 [ 17287 ] {} 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. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000fccaeeb 4. /build/src/Common/ThreadPool.cpp:275: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000fccc813 5. /build/src/Common/ThreadPool.cpp:308: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fcc8286 6. /build/src/Common/ThreadPool.cpp:494: ThreadPoolImpl>::scheduleOrThrowOnError(std::function, Priority) @ 0x000000000fcc7a0e 7. /build/src/Common/threadPoolCallbackRunner.h:188: DB::ThreadPoolCallbackRunnerLocal>, std::function>::operator()(std::function&&, Priority, std::optional) @ 0x00000000119df78e 8. /build/src/Storages/MergeTree/MergeTreeData.cpp:1923: DB::MergeTreeData::loadDataParts(bool, std::optional, std::equal_to, std::allocator>>) @ 0x0000000016314fbd 9. /build/src/Storages/StorageMergeTree.cpp:161: 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>) @ 0x0000000016632c15 10. /build/contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: std::shared_ptr std::allocate_shared[abi:se190107], 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>&&) @ 0x00000000166326f0 11. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:851: DB::create(DB::StorageFactory::Arguments const&) @ 0x000000001662f01d 12. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000015d81ea2 13. /build/src/Interpreters/InterpreterCreateQuery.cpp:1945: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x00000000149009bb 14. /build/src/Interpreters/InterpreterCreateQuery.cpp:1743: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000148f9aa9 15. /build/src/Interpreters/InterpreterCreateQuery.cpp:2352: DB::InterpreterCreateQuery::execute() @ 0x0000000014905a41 16. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88dc9 17. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 18. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 19. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 20. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 21. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 22. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 23. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 24. ? @ 0x00007fbc6213eac3 25. ? @ 0x00007fbc621d0850 2025.07.28 11:51:56.681807 [ 17287 ] {0a81a012-5dbc-4d6b-a59b-4a7ffc7f88d2} executeQuery: Code: 60. DB::Exception: Table test_dixlvgps.t_order_by_monotonic does not exist. (UNKNOWN_TABLE) (version 25.3.6.10636.altinitytest (altinity build)) (from [::1]:60668) (comment: 02451_order_by_monotonic.sh) (query 1, line 1) (in query: INSERT INTO t_order_by_monotonic VALUES ), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000a06a8eb 4. /build/src/Databases/IDatabase.cpp:41: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x0000000013dd565f 5. /build/src/Interpreters/DatabaseCatalog.cpp:442: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x00000000144f0869 6. /build/src/Interpreters/DatabaseCatalog.cpp:976: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x00000000144f6c88 7. /build/src/Interpreters/InterpreterInsertQuery.cpp:169: DB::InterpreterInsertQuery::getTable(DB::ASTInsertQuery&) @ 0x000000001492bf04 8. /build/src/Interpreters/InterpreterInsertQuery.cpp:829: DB::InterpreterInsertQuery::execute() @ 0x0000000014933938 9. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88dc9 10. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 11. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 12. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 13. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 14. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 16. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 17. ? @ 0x00007fbc6213eac3 18. ? @ 0x00007fbc621d0850 2025.07.28 11:51:56.711867 [ 17287 ] {} TCPHandler: Code: 60. DB::Exception: Table test_dixlvgps.t_order_by_monotonic does not exist. (UNKNOWN_TABLE), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000a06a8eb 4. /build/src/Databases/IDatabase.cpp:41: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x0000000013dd565f 5. /build/src/Interpreters/DatabaseCatalog.cpp:442: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x00000000144f0869 6. /build/src/Interpreters/DatabaseCatalog.cpp:976: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x00000000144f6c88 7. /build/src/Interpreters/InterpreterInsertQuery.cpp:169: DB::InterpreterInsertQuery::getTable(DB::ASTInsertQuery&) @ 0x000000001492bf04 8. /build/src/Interpreters/InterpreterInsertQuery.cpp:829: DB::InterpreterInsertQuery::execute() @ 0x0000000014933938 9. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88dc9 10. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 11. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 12. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 13. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 14. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 16. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 17. ? @ 0x00007fbc6213eac3 18. ? @ 0x00007fbc621d0850 2025.07.28 11:51:57.021168 [ 17287 ] {c100992d-5c37-40a2-a480-c230d2c07a0a} executeQuery: Code: 60. DB::Exception: Unknown table expression identifier 't_order_by_monotonic' in scope SELECT * FROM t_order_by_monotonic AS test ORDER BY -a ASC. (UNKNOWN_TABLE) (version 25.3.6.10636.altinitytest (altinity build)) (from [::1]:60684) (comment: 02451_order_by_monotonic.sh) (query 1, line 1) (in query: EXPLAIN PLAN actions = 1 SELECT * FROM t_order_by_monotonic AS test ORDER BY -a), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x000000000a6a1e2b 4. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:4372: DB::QueryAnalyzer::initializeQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000001404440b 5. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5594: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000140135fb 6. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000140127f9 7. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000014011fce 8. /build/src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000001406ce8a 9. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000014973b42 10. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000001497268d 11. /build/src/Interpreters/InterpreterExplainQuery.cpp:507: DB::InterpreterExplainQuery::executeImpl() @ 0x000000001491a4eb 12. /build/src/Interpreters/InterpreterExplainQuery.cpp:130: DB::InterpreterExplainQuery::execute() @ 0x0000000014919fc7 13. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88dc9 14. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 15. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 16. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 17. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 18. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 19. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 20. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 21. ? @ 0x00007fbc6213eac3 22. ? @ 0x00007fbc621d0850 2025.07.28 11:51:57.048724 [ 17287 ] {} TCPHandler: Code: 60. DB::Exception: Unknown table expression identifier 't_order_by_monotonic' in scope SELECT * FROM t_order_by_monotonic AS test ORDER BY -a ASC. (UNKNOWN_TABLE), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x000000000a6a1e2b 4. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:4372: DB::QueryAnalyzer::initializeQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000001404440b 5. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5594: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000140135fb 6. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000140127f9 7. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000014011fce 8. /build/src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000001406ce8a 9. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000014973b42 10. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000001497268d 11. /build/src/Interpreters/InterpreterExplainQuery.cpp:507: DB::InterpreterExplainQuery::executeImpl() @ 0x000000001491a4eb 12. /build/src/Interpreters/InterpreterExplainQuery.cpp:130: DB::InterpreterExplainQuery::execute() @ 0x0000000014919fc7 13. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88dc9 14. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 15. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 16. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 17. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 18. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 19. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 20. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 21. ? @ 0x00007fbc6213eac3 22. ? @ 0x00007fbc621d0850 2025.07.28 11:51:57.185251 [ 3961 ] {} test_13.rmt2 (7f9b740d-015c-470e-8cc6-8ba33be0dc63): auto DB::StorageReplicatedMergeTree::processQueueEntry(ReplicatedMergeTreeQueue::SelectedEntryPtr)::(anonymous class)::operator()(LogEntryPtr &) const: Code: 86. DB::HTTPException: Received error from remote server http://146b4357c08d:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Ftest%2F01165%2Ftest_13%2Frmt%2Freplicas%2F1&part=20250728_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.6.10636.altinitytest (altinity build)) '. (RECEIVED_ERROR_FROM_REMOTE_IO_SERVER), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.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 const&, int&&, String const&, unsigned long&&, String const&) @ 0x000000000feda8d9 4. /build/src/IO/HTTPCommon.cpp:104: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x000000000feda6e2 5. /build/src/IO/HTTPCommon.cpp:93: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x000000000feda537 6. /build/src/IO/ReadWriteBufferFromHTTP.cpp:277: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x000000001184a4c4 7. /build/src/IO/ReadWriteBufferFromHTTP.cpp:285: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x000000001184a615 8. /build/src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x000000001184ae59 9. /build/src/IO/ReadWriteBufferFromHTTP.cpp:472: void std::__function::__policy_invoker::__call_impl[abi:se190107]>(std::__function::__policy_storage const*) @ 0x000000001184cedd 10. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001184858b 11. /build/src/IO/ReadWriteBufferFromHTTP.cpp:465: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x000000001184bf0b 12. /build/src/IO/ReadBuffer.h:60: DB::ReadBuffer::next() @ 0x000000000a148c7b 13. /build/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) @ 0x0000000011849fb2 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]>&)>&, 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&) @ 0x0000000011841980 15. /build/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) @ 0x000000001621208e 16. /build/src/Storages/StorageReplicatedMergeTree.cpp:5228: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl[abi:se190107] const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000015f9a5fe 17. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000015ed8bfd 18. /build/src/Storages/StorageReplicatedMergeTree.cpp:2514: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x0000000015ec9aab 19. /build/src/Storages/StorageReplicatedMergeTree.cpp:2349: DB::StorageReplicatedMergeTree::executeLogEntry(DB::ReplicatedMergeTreeLogEntry&) @ 0x0000000015eba91b 20. /build/src/Storages/StorageReplicatedMergeTree.cpp:3876: bool std::__function::__policy_invoker&)>::__call_impl[abi:se190107])::$_1, bool (std::shared_ptr&)>>(std::__function::__policy_storage const*, std::shared_ptr&) @ 0x0000000015f9837e 21. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000165d6fc3 22. /build/src/Storages/StorageReplicatedMergeTree.cpp:3872: DB::StorageReplicatedMergeTree::processQueueEntry(std::shared_ptr) @ 0x0000000015efc18a 23. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001624c1b2 24. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000162f9c70 25. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x00000000162fa55a 26. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc6653 27. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000000fccc4c3 28. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc3d92 29. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fcca080 30. ? @ 0x00007fbc6213eac3 31. ? @ 0x00007fbc621d0850 (version 25.3.6.10636.altinitytest (altinity build)) 2025.07.28 11:51:57.372952 [ 7630 ] {dad3bb49-ac80-43be-a958-dbae31cb5402} executeQuery: Code: 60. DB::Exception: Unknown table expression identifier 't_order_by_monotonic' in scope SELECT * FROM t_order_by_monotonic AS test ORDER BY -a ASC, -b ASC. (UNKNOWN_TABLE) (version 25.3.6.10636.altinitytest (altinity build)) (from [::1]:60688) (comment: 02451_order_by_monotonic.sh) (query 1, line 1) (in query: EXPLAIN PLAN actions = 1 SELECT * FROM t_order_by_monotonic AS test ORDER BY -a, -b), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x000000000a6a1e2b 4. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:4372: DB::QueryAnalyzer::initializeQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000001404440b 5. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5594: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000140135fb 6. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000140127f9 7. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000014011fce 8. /build/src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000001406ce8a 9. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000014973b42 10. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000001497268d 11. /build/src/Interpreters/InterpreterExplainQuery.cpp:507: DB::InterpreterExplainQuery::executeImpl() @ 0x000000001491a4eb 12. /build/src/Interpreters/InterpreterExplainQuery.cpp:130: DB::InterpreterExplainQuery::execute() @ 0x0000000014919fc7 13. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88dc9 14. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 15. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 16. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 17. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 18. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 19. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 20. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 21. ? @ 0x00007fbc6213eac3 22. ? @ 0x00007fbc621d0850 2025.07.28 11:51:57.405752 [ 7630 ] {} TCPHandler: Code: 60. DB::Exception: Unknown table expression identifier 't_order_by_monotonic' in scope SELECT * FROM t_order_by_monotonic AS test ORDER BY -a ASC, -b ASC. (UNKNOWN_TABLE), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x000000000a6a1e2b 4. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:4372: DB::QueryAnalyzer::initializeQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000001404440b 5. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5594: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000140135fb 6. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000140127f9 7. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000014011fce 8. /build/src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000001406ce8a 9. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000014973b42 10. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000001497268d 11. /build/src/Interpreters/InterpreterExplainQuery.cpp:507: DB::InterpreterExplainQuery::executeImpl() @ 0x000000001491a4eb 12. /build/src/Interpreters/InterpreterExplainQuery.cpp:130: DB::InterpreterExplainQuery::execute() @ 0x0000000014919fc7 13. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88dc9 14. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 15. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 16. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 17. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 18. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 19. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 20. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 21. ? @ 0x00007fbc6213eac3 22. ? @ 0x00007fbc621d0850 2025.07.28 11:51:57.608689 [ 17958 ] {e1976256-2809-4383-b6fd-d15e47d27458} executeQuery: Code: 60. DB::Exception: Unknown table expression identifier 't_order_by_monotonic' in scope SELECT * FROM t_order_by_monotonic AS test ORDER BY a DESC, -b ASC. (UNKNOWN_TABLE) (version 25.3.6.10636.altinitytest (altinity build)) (from [::1]:60730) (comment: 02451_order_by_monotonic.sh) (query 1, line 1) (in query: EXPLAIN PLAN actions = 1 SELECT * FROM t_order_by_monotonic AS test ORDER BY a DESC, -b), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x000000000a6a1e2b 4. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:4372: DB::QueryAnalyzer::initializeQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000001404440b 5. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5594: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000140135fb 6. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000140127f9 7. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000014011fce 8. /build/src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000001406ce8a 9. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000014973b42 10. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000001497268d 11. /build/src/Interpreters/InterpreterExplainQuery.cpp:507: DB::InterpreterExplainQuery::executeImpl() @ 0x000000001491a4eb 12. /build/src/Interpreters/InterpreterExplainQuery.cpp:130: DB::InterpreterExplainQuery::execute() @ 0x0000000014919fc7 13. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88dc9 14. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 15. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 16. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 17. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 18. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 19. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 20. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 21. ? @ 0x00007fbc6213eac3 22. ? @ 0x00007fbc621d0850 2025.07.28 11:51:57.648481 [ 17958 ] {} TCPHandler: Code: 60. DB::Exception: Unknown table expression identifier 't_order_by_monotonic' in scope SELECT * FROM t_order_by_monotonic AS test ORDER BY a DESC, -b ASC. (UNKNOWN_TABLE), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x000000000a6a1e2b 4. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:4372: DB::QueryAnalyzer::initializeQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000001404440b 5. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5594: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000140135fb 6. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000140127f9 7. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000014011fce 8. /build/src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000001406ce8a 9. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000014973b42 10. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000001497268d 11. /build/src/Interpreters/InterpreterExplainQuery.cpp:507: DB::InterpreterExplainQuery::executeImpl() @ 0x000000001491a4eb 12. /build/src/Interpreters/InterpreterExplainQuery.cpp:130: DB::InterpreterExplainQuery::execute() @ 0x0000000014919fc7 13. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88dc9 14. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 15. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 16. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 17. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 18. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 19. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 20. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 21. ? @ 0x00007fbc6213eac3 22. ? @ 0x00007fbc621d0850 2025.07.28 11:51:57.752000 [ 3960 ] {} test_13.rmt2 (7f9b740d-015c-470e-8cc6-8ba33be0dc63): auto DB::StorageReplicatedMergeTree::processQueueEntry(ReplicatedMergeTreeQueue::SelectedEntryPtr)::(anonymous class)::operator()(LogEntryPtr &) const: Code: 86. DB::HTTPException: Received error from remote server http://146b4357c08d:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Ftest%2F01165%2Ftest_13%2Frmt%2Freplicas%2F1&part=20250728_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.6.10636.altinitytest (altinity build)) '. (RECEIVED_ERROR_FROM_REMOTE_IO_SERVER), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.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 const&, int&&, String const&, unsigned long&&, String const&) @ 0x000000000feda8d9 4. /build/src/IO/HTTPCommon.cpp:104: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x000000000feda6e2 5. /build/src/IO/HTTPCommon.cpp:93: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x000000000feda537 6. /build/src/IO/ReadWriteBufferFromHTTP.cpp:277: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x000000001184a4c4 7. /build/src/IO/ReadWriteBufferFromHTTP.cpp:285: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x000000001184a615 8. /build/src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x000000001184ae59 9. /build/src/IO/ReadWriteBufferFromHTTP.cpp:472: void std::__function::__policy_invoker::__call_impl[abi:se190107]>(std::__function::__policy_storage const*) @ 0x000000001184cedd 10. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001184858b 11. /build/src/IO/ReadWriteBufferFromHTTP.cpp:465: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x000000001184bf0b 12. /build/src/IO/ReadBuffer.h:60: DB::ReadBuffer::next() @ 0x000000000a148c7b 13. /build/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) @ 0x0000000011849fb2 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]>&)>&, 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&) @ 0x0000000011841980 15. /build/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) @ 0x000000001621208e 16. /build/src/Storages/StorageReplicatedMergeTree.cpp:5228: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl[abi:se190107] const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000015f9a5fe 17. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000015ed8bfd 18. /build/src/Storages/StorageReplicatedMergeTree.cpp:2514: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x0000000015ec9aab 19. /build/src/Storages/StorageReplicatedMergeTree.cpp:2349: DB::StorageReplicatedMergeTree::executeLogEntry(DB::ReplicatedMergeTreeLogEntry&) @ 0x0000000015eba91b 20. /build/src/Storages/StorageReplicatedMergeTree.cpp:3876: bool std::__function::__policy_invoker&)>::__call_impl[abi:se190107])::$_1, bool (std::shared_ptr&)>>(std::__function::__policy_storage const*, std::shared_ptr&) @ 0x0000000015f9837e 21. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000165d6fc3 22. /build/src/Storages/StorageReplicatedMergeTree.cpp:3872: DB::StorageReplicatedMergeTree::processQueueEntry(std::shared_ptr) @ 0x0000000015efc18a 23. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001624c1b2 24. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000162f9c70 25. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x00000000162fa55a 26. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc6653 27. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000000fccc4c3 28. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc3d92 29. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fcca080 30. ? @ 0x00007fbc6213eac3 31. ? @ 0x00007fbc621d0850 (version 25.3.6.10636.altinitytest (altinity build)) 2025.07.28 11:51:57.915784 [ 3974 ] {} test_13.rmt2 (7f9b740d-015c-470e-8cc6-8ba33be0dc63): auto DB::StorageReplicatedMergeTree::processQueueEntry(ReplicatedMergeTreeQueue::SelectedEntryPtr)::(anonymous class)::operator()(LogEntryPtr &) const: Code: 86. DB::HTTPException: Received error from remote server http://146b4357c08d:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Ftest%2F01165%2Ftest_13%2Frmt%2Freplicas%2F1&part=20250728_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.6.10636.altinitytest (altinity build)) '. (RECEIVED_ERROR_FROM_REMOTE_IO_SERVER), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.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 const&, int&&, String const&, unsigned long&&, String const&) @ 0x000000000feda8d9 4. /build/src/IO/HTTPCommon.cpp:104: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x000000000feda6e2 5. /build/src/IO/HTTPCommon.cpp:93: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x000000000feda537 6. /build/src/IO/ReadWriteBufferFromHTTP.cpp:277: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x000000001184a4c4 7. /build/src/IO/ReadWriteBufferFromHTTP.cpp:285: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x000000001184a615 8. /build/src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x000000001184ae59 9. /build/src/IO/ReadWriteBufferFromHTTP.cpp:472: void std::__function::__policy_invoker::__call_impl[abi:se190107]>(std::__function::__policy_storage const*) @ 0x000000001184cedd 10. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001184858b 11. /build/src/IO/ReadWriteBufferFromHTTP.cpp:465: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x000000001184bf0b 12. /build/src/IO/ReadBuffer.h:60: DB::ReadBuffer::next() @ 0x000000000a148c7b 13. /build/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) @ 0x0000000011849fb2 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]>&)>&, 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&) @ 0x0000000011841980 15. /build/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) @ 0x000000001621208e 16. /build/src/Storages/StorageReplicatedMergeTree.cpp:5228: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl[abi:se190107] const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000015f9a5fe 17. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000015ed8bfd 18. /build/src/Storages/StorageReplicatedMergeTree.cpp:2514: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x0000000015ec9aab 19. /build/src/Storages/StorageReplicatedMergeTree.cpp:2349: DB::StorageReplicatedMergeTree::executeLogEntry(DB::ReplicatedMergeTreeLogEntry&) @ 0x0000000015eba91b 20. /build/src/Storages/StorageReplicatedMergeTree.cpp:3876: bool std::__function::__policy_invoker&)>::__call_impl[abi:se190107])::$_1, bool (std::shared_ptr&)>>(std::__function::__policy_storage const*, std::shared_ptr&) @ 0x0000000015f9837e 21. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000165d6fc3 22. /build/src/Storages/StorageReplicatedMergeTree.cpp:3872: DB::StorageReplicatedMergeTree::processQueueEntry(std::shared_ptr) @ 0x0000000015efc18a 23. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001624c1b2 24. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000162f9c70 25. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x00000000162fa55a 26. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc6653 27. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000000fccc4c3 28. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc3d92 29. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fcca080 30. ? @ 0x00007fbc6213eac3 31. ? @ 0x00007fbc621d0850 (version 25.3.6.10636.altinitytest (altinity build)) 2025.07.28 11:51:57.952562 [ 17958 ] {9df5f86e-2762-4043-a4c4-fff0db798eb3} executeQuery: Code: 60. DB::Exception: Unknown table expression identifier 't_order_by_monotonic' in scope SELECT * FROM t_order_by_monotonic AS test ORDER BY -a ASC, b DESC. (UNKNOWN_TABLE) (version 25.3.6.10636.altinitytest (altinity build)) (from [::1]:60748) (comment: 02451_order_by_monotonic.sh) (query 1, line 1) (in query: EXPLAIN PLAN actions = 1 SELECT * FROM t_order_by_monotonic AS test ORDER BY -a, b DESC), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x000000000a6a1e2b 4. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:4372: DB::QueryAnalyzer::initializeQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000001404440b 5. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5594: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000140135fb 6. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000140127f9 7. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000014011fce 8. /build/src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000001406ce8a 9. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000014973b42 10. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000001497268d 11. /build/src/Interpreters/InterpreterExplainQuery.cpp:507: DB::InterpreterExplainQuery::executeImpl() @ 0x000000001491a4eb 12. /build/src/Interpreters/InterpreterExplainQuery.cpp:130: DB::InterpreterExplainQuery::execute() @ 0x0000000014919fc7 13. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88dc9 14. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 15. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 16. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 17. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 18. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 19. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 20. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 21. ? @ 0x00007fbc6213eac3 22. ? @ 0x00007fbc621d0850 2025.07.28 11:51:58.008495 [ 17958 ] {} TCPHandler: Code: 60. DB::Exception: Unknown table expression identifier 't_order_by_monotonic' in scope SELECT * FROM t_order_by_monotonic AS test ORDER BY -a ASC, b DESC. (UNKNOWN_TABLE), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x000000000a6a1e2b 4. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:4372: DB::QueryAnalyzer::initializeQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000001404440b 5. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5594: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000140135fb 6. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000140127f9 7. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000014011fce 8. /build/src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000001406ce8a 9. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000014973b42 10. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000001497268d 11. /build/src/Interpreters/InterpreterExplainQuery.cpp:507: DB::InterpreterExplainQuery::executeImpl() @ 0x000000001491a4eb 12. /build/src/Interpreters/InterpreterExplainQuery.cpp:130: DB::InterpreterExplainQuery::execute() @ 0x0000000014919fc7 13. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88dc9 14. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 15. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 16. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 17. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 18. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 19. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 20. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 21. ? @ 0x00007fbc6213eac3 22. ? @ 0x00007fbc621d0850 2025.07.28 11:51:58.294717 [ 17958 ] {e1554b15-7140-4a02-b288-9bfa74a9fb7b} executeQuery: Code: 60. DB::Exception: Unknown table expression identifier 't_order_by_monotonic' in scope SELECT * FROM t_order_by_monotonic AS test ORDER BY -a ASC, b ASC. (UNKNOWN_TABLE) (version 25.3.6.10636.altinitytest (altinity build)) (from [::1]:60762) (comment: 02451_order_by_monotonic.sh) (query 1, line 1) (in query: EXPLAIN PLAN actions = 1 SELECT * FROM t_order_by_monotonic AS test ORDER BY -a, b), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x000000000a6a1e2b 4. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:4372: DB::QueryAnalyzer::initializeQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000001404440b 5. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5594: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000140135fb 6. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000140127f9 7. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000014011fce 8. /build/src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000001406ce8a 9. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000014973b42 10. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000001497268d 11. /build/src/Interpreters/InterpreterExplainQuery.cpp:507: DB::InterpreterExplainQuery::executeImpl() @ 0x000000001491a4eb 12. /build/src/Interpreters/InterpreterExplainQuery.cpp:130: DB::InterpreterExplainQuery::execute() @ 0x0000000014919fc7 13. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88dc9 14. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 15. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 16. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 17. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 18. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 19. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 20. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 21. ? @ 0x00007fbc6213eac3 22. ? @ 0x00007fbc621d0850 2025.07.28 11:51:58.317207 [ 17958 ] {} TCPHandler: Code: 60. DB::Exception: Unknown table expression identifier 't_order_by_monotonic' in scope SELECT * FROM t_order_by_monotonic AS test ORDER BY -a ASC, b ASC. (UNKNOWN_TABLE), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x000000000a6a1e2b 4. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:4372: DB::QueryAnalyzer::initializeQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000001404440b 5. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5594: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000140135fb 6. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000140127f9 7. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000014011fce 8. /build/src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000001406ce8a 9. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000014973b42 10. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000001497268d 11. /build/src/Interpreters/InterpreterExplainQuery.cpp:507: DB::InterpreterExplainQuery::executeImpl() @ 0x000000001491a4eb 12. /build/src/Interpreters/InterpreterExplainQuery.cpp:130: DB::InterpreterExplainQuery::execute() @ 0x0000000014919fc7 13. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88dc9 14. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 15. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 16. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 17. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 18. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 19. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 20. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 21. ? @ 0x00007fbc6213eac3 22. ? @ 0x00007fbc621d0850 2025.07.28 11:51:58.582088 [ 17191 ] {e3e4a9a2-2fcc-4db7-bcad-47a518d091d8} executeQuery: Code: 60. DB::Exception: Unknown table expression identifier 't_order_by_monotonic' in scope SELECT * FROM t_order_by_monotonic AS test ORDER BY a ASC, -b ASC. (UNKNOWN_TABLE) (version 25.3.6.10636.altinitytest (altinity build)) (from [::1]:60790) (comment: 02451_order_by_monotonic.sh) (query 1, line 1) (in query: EXPLAIN PLAN actions = 1 SELECT * FROM t_order_by_monotonic AS test ORDER BY a, -b), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x000000000a6a1e2b 4. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:4372: DB::QueryAnalyzer::initializeQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000001404440b 5. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5594: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000140135fb 6. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000140127f9 7. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000014011fce 8. /build/src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000001406ce8a 9. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000014973b42 10. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000001497268d 11. /build/src/Interpreters/InterpreterExplainQuery.cpp:507: DB::InterpreterExplainQuery::executeImpl() @ 0x000000001491a4eb 12. /build/src/Interpreters/InterpreterExplainQuery.cpp:130: DB::InterpreterExplainQuery::execute() @ 0x0000000014919fc7 13. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88dc9 14. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 15. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 16. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 17. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 18. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 19. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 20. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 21. ? @ 0x00007fbc6213eac3 22. ? @ 0x00007fbc621d0850 2025.07.28 11:51:58.600663 [ 17191 ] {} TCPHandler: Code: 60. DB::Exception: Unknown table expression identifier 't_order_by_monotonic' in scope SELECT * FROM t_order_by_monotonic AS test ORDER BY a ASC, -b ASC. (UNKNOWN_TABLE), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x000000000a6a1e2b 4. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:4372: DB::QueryAnalyzer::initializeQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000001404440b 5. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5594: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000140135fb 6. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000140127f9 7. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000014011fce 8. /build/src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000001406ce8a 9. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000014973b42 10. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000001497268d 11. /build/src/Interpreters/InterpreterExplainQuery.cpp:507: DB::InterpreterExplainQuery::executeImpl() @ 0x000000001491a4eb 12. /build/src/Interpreters/InterpreterExplainQuery.cpp:130: DB::InterpreterExplainQuery::execute() @ 0x0000000014919fc7 13. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88dc9 14. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 15. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 16. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 17. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 18. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 19. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 20. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 21. ? @ 0x00007fbc6213eac3 22. ? @ 0x00007fbc621d0850 2025.07.28 11:51:58.732374 [ 3964 ] {} test_13.rmt2 (7f9b740d-015c-470e-8cc6-8ba33be0dc63): auto DB::StorageReplicatedMergeTree::processQueueEntry(ReplicatedMergeTreeQueue::SelectedEntryPtr)::(anonymous class)::operator()(LogEntryPtr &) const: Code: 86. DB::HTTPException: Received error from remote server http://146b4357c08d:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Ftest%2F01165%2Ftest_13%2Frmt%2Freplicas%2F1&part=20250728_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.6.10636.altinitytest (altinity build)) '. (RECEIVED_ERROR_FROM_REMOTE_IO_SERVER), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.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 const&, int&&, String const&, unsigned long&&, String const&) @ 0x000000000feda8d9 4. /build/src/IO/HTTPCommon.cpp:104: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x000000000feda6e2 5. /build/src/IO/HTTPCommon.cpp:93: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x000000000feda537 6. /build/src/IO/ReadWriteBufferFromHTTP.cpp:277: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x000000001184a4c4 7. /build/src/IO/ReadWriteBufferFromHTTP.cpp:285: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x000000001184a615 8. /build/src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x000000001184ae59 9. /build/src/IO/ReadWriteBufferFromHTTP.cpp:472: void std::__function::__policy_invoker::__call_impl[abi:se190107]>(std::__function::__policy_storage const*) @ 0x000000001184cedd 10. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001184858b 11. /build/src/IO/ReadWriteBufferFromHTTP.cpp:465: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x000000001184bf0b 12. /build/src/IO/ReadBuffer.h:60: DB::ReadBuffer::next() @ 0x000000000a148c7b 13. /build/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) @ 0x0000000011849fb2 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]>&)>&, 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&) @ 0x0000000011841980 15. /build/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) @ 0x000000001621208e 16. /build/src/Storages/StorageReplicatedMergeTree.cpp:5228: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl[abi:se190107] const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000015f9a5fe 17. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000015ed8bfd 18. /build/src/Storages/StorageReplicatedMergeTree.cpp:2514: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x0000000015ec9aab 19. /build/src/Storages/StorageReplicatedMergeTree.cpp:2349: DB::StorageReplicatedMergeTree::executeLogEntry(DB::ReplicatedMergeTreeLogEntry&) @ 0x0000000015eba91b 20. /build/src/Storages/StorageReplicatedMergeTree.cpp:3876: bool std::__function::__policy_invoker&)>::__call_impl[abi:se190107])::$_1, bool (std::shared_ptr&)>>(std::__function::__policy_storage const*, std::shared_ptr&) @ 0x0000000015f9837e 21. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000165d6fc3 22. /build/src/Storages/StorageReplicatedMergeTree.cpp:3872: DB::StorageReplicatedMergeTree::processQueueEntry(std::shared_ptr) @ 0x0000000015efc18a 23. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001624c1b2 24. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000162f9c70 25. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x00000000162fa55a 26. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc6653 27. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000000fccc4c3 28. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc3d92 29. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fcca080 30. ? @ 0x00007fbc6213eac3 31. ? @ 0x00007fbc621d0850 (version 25.3.6.10636.altinitytest (altinity build)) 2025.07.28 11:51:59.388521 [ 3972 ] {} test_13.rmt2 (7f9b740d-015c-470e-8cc6-8ba33be0dc63): auto DB::StorageReplicatedMergeTree::processQueueEntry(ReplicatedMergeTreeQueue::SelectedEntryPtr)::(anonymous class)::operator()(LogEntryPtr &) const: Code: 86. DB::HTTPException: Received error from remote server http://146b4357c08d:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Ftest%2F01165%2Ftest_13%2Frmt%2Freplicas%2F1&part=20250728_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.6.10636.altinitytest (altinity build)) '. (RECEIVED_ERROR_FROM_REMOTE_IO_SERVER), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.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 const&, int&&, String const&, unsigned long&&, String const&) @ 0x000000000feda8d9 4. /build/src/IO/HTTPCommon.cpp:104: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x000000000feda6e2 5. /build/src/IO/HTTPCommon.cpp:93: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x000000000feda537 6. /build/src/IO/ReadWriteBufferFromHTTP.cpp:277: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x000000001184a4c4 7. /build/src/IO/ReadWriteBufferFromHTTP.cpp:285: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x000000001184a615 8. /build/src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x000000001184ae59 9. /build/src/IO/ReadWriteBufferFromHTTP.cpp:472: void std::__function::__policy_invoker::__call_impl[abi:se190107]>(std::__function::__policy_storage const*) @ 0x000000001184cedd 10. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001184858b 11. /build/src/IO/ReadWriteBufferFromHTTP.cpp:465: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x000000001184bf0b 12. /build/src/IO/ReadBuffer.h:60: DB::ReadBuffer::next() @ 0x000000000a148c7b 13. /build/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) @ 0x0000000011849fb2 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]>&)>&, 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&) @ 0x0000000011841980 15. /build/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) @ 0x000000001621208e 16. /build/src/Storages/StorageReplicatedMergeTree.cpp:5228: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl[abi:se190107] const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000015f9a5fe 17. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000015ed8bfd 18. /build/src/Storages/StorageReplicatedMergeTree.cpp:2514: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x0000000015ec9aab 19. /build/src/Storages/StorageReplicatedMergeTree.cpp:2349: DB::StorageReplicatedMergeTree::executeLogEntry(DB::ReplicatedMergeTreeLogEntry&) @ 0x0000000015eba91b 20. /build/src/Storages/StorageReplicatedMergeTree.cpp:3876: bool std::__function::__policy_invoker&)>::__call_impl[abi:se190107])::$_1, bool (std::shared_ptr&)>>(std::__function::__policy_storage const*, std::shared_ptr&) @ 0x0000000015f9837e 21. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000165d6fc3 22. /build/src/Storages/StorageReplicatedMergeTree.cpp:3872: DB::StorageReplicatedMergeTree::processQueueEntry(std::shared_ptr) @ 0x0000000015efc18a 23. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001624c1b2 24. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000162f9c70 25. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x00000000162fa55a 26. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc6653 27. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000000fccc4c3 28. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc3d92 29. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fcca080 30. ? @ 0x00007fbc6213eac3 31. ? @ 0x00007fbc621d0850 (version 25.3.6.10636.altinitytest (altinity build)) 2025.07.28 11:51:59.487833 [ 17256 ] {ad82d883-5cbd-406f-842c-cdf7131a1f9d} executeQuery: Code: 48. DB::Exception: Alter of type 'COMMENT_COLUMN' is not supported by storage Dictionary. (NOT_IMPLEMENTED) (version 25.3.6.10636.altinitytest (altinity build)) (from [::1]:60480) (comment: 02155_dictionary_comment.sql) (query 20, line 45) (in query: ALTER TABLE 02155_test_dictionary_view COMMENT COLUMN value 'value_column';), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, DB::AlterCommand::Type const&, String&&) @ 0x00000000134653eb 4. /build/src/Storages/StorageDictionary.cpp:303: DB::StorageDictionary::checkAlterIsPossible(DB::AlterCommands const&, std::shared_ptr) const @ 0x0000000015d59ddc 5. /build/src/Interpreters/InterpreterAlterQuery.cpp:215: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x00000000148deab3 6. /build/src/Interpreters/InterpreterAlterQuery.cpp:77: DB::InterpreterAlterQuery::execute() @ 0x00000000148dcb0d 7. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88dc9 8. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 9. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 10. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 11. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 12. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 13. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 14. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 15. ? @ 0x00007fbc6213eac3 16. ? @ 0x00007fbc621d0850 2025.07.28 11:51:59.490473 [ 17256 ] {} TCPHandler: Code: 48. DB::Exception: Alter of type 'COMMENT_COLUMN' is not supported by storage Dictionary. (NOT_IMPLEMENTED), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, DB::AlterCommand::Type const&, String&&) @ 0x00000000134653eb 4. /build/src/Storages/StorageDictionary.cpp:303: DB::StorageDictionary::checkAlterIsPossible(DB::AlterCommands const&, std::shared_ptr) const @ 0x0000000015d59ddc 5. /build/src/Interpreters/InterpreterAlterQuery.cpp:215: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x00000000148deab3 6. /build/src/Interpreters/InterpreterAlterQuery.cpp:77: DB::InterpreterAlterQuery::execute() @ 0x00000000148dcb0d 7. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88dc9 8. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 9. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 10. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 11. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 12. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 13. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 14. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 15. ? @ 0x00007fbc6213eac3 16. ? @ 0x00007fbc621d0850 2025.07.28 11:52:00.102914 [ 17256 ] {41b8778d-63b3-4882-9bb9-3613dc053e83} executeQuery: Code: 62. DB::Exception: Cannot TRUNCATE dictionary. (SYNTAX_ERROR) (version 25.3.6.10636.altinitytest (altinity build)) (from [::1]:60480) (comment: 02155_dictionary_comment.sql) (query 24, line 51) (in query: DROP TABLE 02155_test_dictionary_view;), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000000a074fcb 4. /build/src/Interpreters/InterpreterDropQuery.cpp:266: DB::InterpreterDropQuery::executeToTableImpl(std::shared_ptr const&, DB::ASTDropQuery&, std::shared_ptr&, StrongTypedef, DB::UUIDTag>&) @ 0x0000000014915b7b 5. /build/src/Interpreters/InterpreterDropQuery.cpp:118: DB::InterpreterDropQuery::executeToTable(DB::ASTDropQuery&) @ 0x00000000149137b4 6. /build/src/Interpreters/InterpreterDropQuery.cpp:91: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000014912f07 7. /build/src/Interpreters/InterpreterDropQuery.cpp:72: DB::InterpreterDropQuery::execute() @ 0x0000000014912b65 8. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88dc9 9. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 10. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 11. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 12. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 13. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 14. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 15. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 16. ? @ 0x00007fbc6213eac3 17. ? @ 0x00007fbc621d0850 2025.07.28 11:52:00.117766 [ 17256 ] {} TCPHandler: Code: 62. DB::Exception: Cannot TRUNCATE dictionary. (SYNTAX_ERROR), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000000a074fcb 4. /build/src/Interpreters/InterpreterDropQuery.cpp:266: DB::InterpreterDropQuery::executeToTableImpl(std::shared_ptr const&, DB::ASTDropQuery&, std::shared_ptr&, StrongTypedef, DB::UUIDTag>&) @ 0x0000000014915b7b 5. /build/src/Interpreters/InterpreterDropQuery.cpp:118: DB::InterpreterDropQuery::executeToTable(DB::ASTDropQuery&) @ 0x00000000149137b4 6. /build/src/Interpreters/InterpreterDropQuery.cpp:91: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000014912f07 7. /build/src/Interpreters/InterpreterDropQuery.cpp:72: DB::InterpreterDropQuery::execute() @ 0x0000000014912b65 8. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88dc9 9. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 10. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 11. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 12. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 13. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 14. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 15. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 16. ? @ 0x00007fbc6213eac3 17. ? @ 0x00007fbc621d0850 2025.07.28 11:52:00.189721 [ 3968 ] {} test_13.rmt2 (7f9b740d-015c-470e-8cc6-8ba33be0dc63): auto DB::StorageReplicatedMergeTree::processQueueEntry(ReplicatedMergeTreeQueue::SelectedEntryPtr)::(anonymous class)::operator()(LogEntryPtr &) const: Code: 86. DB::HTTPException: Received error from remote server http://146b4357c08d:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Ftest%2F01165%2Ftest_13%2Frmt%2Freplicas%2F1&part=20250728_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.6.10636.altinitytest (altinity build)) '. (RECEIVED_ERROR_FROM_REMOTE_IO_SERVER), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.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 const&, int&&, String const&, unsigned long&&, String const&) @ 0x000000000feda8d9 4. /build/src/IO/HTTPCommon.cpp:104: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x000000000feda6e2 5. /build/src/IO/HTTPCommon.cpp:93: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x000000000feda537 6. /build/src/IO/ReadWriteBufferFromHTTP.cpp:277: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x000000001184a4c4 7. /build/src/IO/ReadWriteBufferFromHTTP.cpp:285: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x000000001184a615 8. /build/src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x000000001184ae59 9. /build/src/IO/ReadWriteBufferFromHTTP.cpp:472: void std::__function::__policy_invoker::__call_impl[abi:se190107]>(std::__function::__policy_storage const*) @ 0x000000001184cedd 10. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001184858b 11. /build/src/IO/ReadWriteBufferFromHTTP.cpp:465: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x000000001184bf0b 12. /build/src/IO/ReadBuffer.h:60: DB::ReadBuffer::next() @ 0x000000000a148c7b 13. /build/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) @ 0x0000000011849fb2 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]>&)>&, 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&) @ 0x0000000011841980 15. /build/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) @ 0x000000001621208e 16. /build/src/Storages/StorageReplicatedMergeTree.cpp:5228: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl[abi:se190107] const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000015f9a5fe 17. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000015ed8bfd 18. /build/src/Storages/StorageReplicatedMergeTree.cpp:2514: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x0000000015ec9aab 19. /build/src/Storages/StorageReplicatedMergeTree.cpp:2349: DB::StorageReplicatedMergeTree::executeLogEntry(DB::ReplicatedMergeTreeLogEntry&) @ 0x0000000015eba91b 20. /build/src/Storages/StorageReplicatedMergeTree.cpp:3876: bool std::__function::__policy_invoker&)>::__call_impl[abi:se190107])::$_1, bool (std::shared_ptr&)>>(std::__function::__policy_storage const*, std::shared_ptr&) @ 0x0000000015f9837e 21. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000165d6fc3 22. /build/src/Storages/StorageReplicatedMergeTree.cpp:3872: DB::StorageReplicatedMergeTree::processQueueEntry(std::shared_ptr) @ 0x0000000015efc18a 23. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001624c1b2 24. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000162f9c70 25. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x00000000162fa55a 26. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc6653 27. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000000fccc4c3 28. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc3d92 29. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fcca080 30. ? @ 0x00007fbc6213eac3 31. ? @ 0x00007fbc621d0850 (version 25.3.6.10636.altinitytest (altinity build)) 2025.07.28 11:52:00.430858 [ 4259 ] {} 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. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: Coordination::Exception::Exception(T&&, Coordination::Error) @ 0x000000001660315b 3. /build/src/Common/ZooKeeper/KeeperException.h:58: Coordination::Exception Coordination::Exception::fromMessage(Coordination::Error, T&&) @ 0x00000000171a88d0 4. /build/src/Common/ZooKeeper/ZooKeeperImpl.cpp:1795: Coordination::ZooKeeper::maybeInjectRecvFault() @ 0x00000000171a20f1 5. /build/src/Common/ZooKeeper/ZooKeeperImpl.cpp:928: Coordination::ZooKeeper::receiveEvent() @ 0x00000000171a115e 6. /build/src/Common/ZooKeeper/ZooKeeperImpl.cpp:875: Coordination::ZooKeeper::receiveThread() @ 0x00000000171a0898 7. /build/src/Common/ZooKeeper/ZooKeeperImpl.cpp:452: void std::__function::__policy_invoker::__call_impl[abi:se190107]::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*) @ 0x00000000171a778a 8. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc3d92 9. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fcca080 10. ? @ 0x00007fbc6213eac3 11. ? @ 0x00007fbc621d0850 (version 25.3.6.10636.altinitytest (altinity build)) 2025.07.28 11:52:00.452514 [ 3372 ] {} test_13.rmt1 (ReplicatedMergeTreeRestartingThread): ZooKeeper session has expired. Switching to a new session. 2025.07.28 11:52:00.454142 [ 3455 ] {} test_1.replicated_table_r1 (ReplicatedMergeTreeRestartingThread): ZooKeeper session has expired. Switching to a new session. 2025.07.28 11:52:00.456266 [ 3596 ] {} test_13.rmt2 (ReplicatedMergeTreeRestartingThread): ZooKeeper session has expired. Switching to a new session. 2025.07.28 11:52:00.463141 [ 3754 ] {} test_1.replicated_table_r2 (ReplicatedMergeTreeRestartingThread): ZooKeeper session has expired. Switching to a new session. 2025.07.28 11:52:00.575221 [ 17251 ] {f308b1bc-5069-4a69-8ea9-a9131c01daba} executeQuery: Code: 236. DB::Exception: Shutdown is called for table. (ABORTED) (version 25.3.6.10636.altinitytest (altinity build)) (from [::1]:55988) (comment: 01165_lost_part_empty_partition.sql) (query 9, line 15) (in query: system sync replica rmt2;), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000000a074fcb 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:9235: DB::StorageReplicatedMergeTree::waitForProcessingQueue(unsigned long, DB::SyncReplicaMode, std::unordered_set, std::equal_to, std::allocator>) @ 0x0000000015f70333 5. /build/src/Interpreters/InterpreterSystemQuery.cpp:1244: DB::InterpreterSystemQuery::trySyncReplica(std::shared_ptr, DB::SyncReplicaMode, std::unordered_set, std::equal_to, std::allocator> const&, std::shared_ptr) @ 0x0000000014cc9e93 6. /build/src/Interpreters/InterpreterSystemQuery.cpp:1263: DB::InterpreterSystemQuery::syncReplica(DB::ASTSystemQuery&) @ 0x0000000014cc2871 7. /build/src/Interpreters/InterpreterSystemQuery.cpp:742: DB::InterpreterSystemQuery::execute() @ 0x0000000014cb7af0 8. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88dc9 9. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 10. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 11. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 12. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 13. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 14. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 15. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 16. ? @ 0x00007fbc6213eac3 17. ? @ 0x00007fbc621d0850 2025.07.28 11:52:00.583436 [ 17251 ] {} TCPHandler: Code: 236. DB::Exception: Shutdown is called for table. (ABORTED), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000000a074fcb 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:9235: DB::StorageReplicatedMergeTree::waitForProcessingQueue(unsigned long, DB::SyncReplicaMode, std::unordered_set, std::equal_to, std::allocator>) @ 0x0000000015f70333 5. /build/src/Interpreters/InterpreterSystemQuery.cpp:1244: DB::InterpreterSystemQuery::trySyncReplica(std::shared_ptr, DB::SyncReplicaMode, std::unordered_set, std::equal_to, std::allocator> const&, std::shared_ptr) @ 0x0000000014cc9e93 6. /build/src/Interpreters/InterpreterSystemQuery.cpp:1263: DB::InterpreterSystemQuery::syncReplica(DB::ASTSystemQuery&) @ 0x0000000014cc2871 7. /build/src/Interpreters/InterpreterSystemQuery.cpp:742: DB::InterpreterSystemQuery::execute() @ 0x0000000014cb7af0 8. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88dc9 9. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 10. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 11. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 12. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 13. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 14. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 15. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 16. ? @ 0x00007fbc6213eac3 17. ? @ 0x00007fbc621d0850 2025.07.28 11:52:01.172328 [ 3961 ] {} test_13.rmt2 (7f9b740d-015c-470e-8cc6-8ba33be0dc63): auto DB::StorageReplicatedMergeTree::processQueueEntry(ReplicatedMergeTreeQueue::SelectedEntryPtr)::(anonymous class)::operator()(LogEntryPtr &) const: Code: 86. DB::HTTPException: Received error from remote server http://146b4357c08d:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Ftest%2F01165%2Ftest_13%2Frmt%2Freplicas%2F1&part=20250728_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.6.10636.altinitytest (altinity build)) '. (RECEIVED_ERROR_FROM_REMOTE_IO_SERVER), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.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 const&, int&&, String const&, unsigned long&&, String const&) @ 0x000000000feda8d9 4. /build/src/IO/HTTPCommon.cpp:104: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x000000000feda6e2 5. /build/src/IO/HTTPCommon.cpp:93: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x000000000feda537 6. /build/src/IO/ReadWriteBufferFromHTTP.cpp:277: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x000000001184a4c4 7. /build/src/IO/ReadWriteBufferFromHTTP.cpp:285: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x000000001184a615 8. /build/src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x000000001184ae59 9. /build/src/IO/ReadWriteBufferFromHTTP.cpp:472: void std::__function::__policy_invoker::__call_impl[abi:se190107]>(std::__function::__policy_storage const*) @ 0x000000001184cedd 10. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001184858b 11. /build/src/IO/ReadWriteBufferFromHTTP.cpp:465: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x000000001184bf0b 12. /build/src/IO/ReadBuffer.h:60: DB::ReadBuffer::next() @ 0x000000000a148c7b 13. /build/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) @ 0x0000000011849fb2 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]>&)>&, 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&) @ 0x0000000011841980 15. /build/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) @ 0x000000001621208e 16. /build/src/Storages/StorageReplicatedMergeTree.cpp:5228: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl[abi:se190107] const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000015f9a5fe 17. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000015ed8bfd 18. /build/src/Storages/StorageReplicatedMergeTree.cpp:2514: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x0000000015ec9aab 19. /build/src/Storages/StorageReplicatedMergeTree.cpp:2349: DB::StorageReplicatedMergeTree::executeLogEntry(DB::ReplicatedMergeTreeLogEntry&) @ 0x0000000015eba91b 20. /build/src/Storages/StorageReplicatedMergeTree.cpp:3876: bool std::__function::__policy_invoker&)>::__call_impl[abi:se190107])::$_1, bool (std::shared_ptr&)>>(std::__function::__policy_storage const*, std::shared_ptr&) @ 0x0000000015f9837e 21. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000165d6fc3 22. /build/src/Storages/StorageReplicatedMergeTree.cpp:3872: DB::StorageReplicatedMergeTree::processQueueEntry(std::shared_ptr) @ 0x0000000015efc18a 23. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001624c1b2 24. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000162f9c70 25. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x00000000162fa55a 26. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc6653 27. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000000fccc4c3 28. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc3d92 29. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fcca080 30. ? @ 0x00007fbc6213eac3 31. ? @ 0x00007fbc621d0850 (version 25.3.6.10636.altinitytest (altinity build)) 2025.07.28 11:52:01.743295 [ 7415 ] {} DDLWorker(test_9_db): Replica seems to be lost: our_log_ptr=63, max_log_ptr=63, local_digest=12324251040984097656, zk_digest=15905701279159345531 2025.07.28 11:52:01.749757 [ 7415 ] {} DatabaseReplicated (test_9_db): Will recover replica with staled log pointer 63 from log pointer 63 2025.07.28 11:52:01.842302 [ 5951 ] {dc512f16-4e8a-4dd5-840f-c8a461b0d46b} executeQuery: Code: 571. DB::Exception: ZooKeeper session expired or replication stopped, try again. (DATABASE_REPLICATION_FAILED) (version 25.3.6.10636.altinitytest (altinity build)) (from [::1]:50536) (comment: 01821_join_table_race_long.sh) (query 101, line 101) (in query: TRUNCATE TABLE join_table_race;), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000000a074fcb 4. /build/src/Databases/DatabaseReplicatedWorker.cpp:352: DB::DatabaseReplicatedDDLWorker::tryEnqueueAndExecuteEntry(DB::DDLLogEntry&, std::shared_ptr, bool)::$_1::operator()() const @ 0x0000000013dc6b95 5. /build/contrib/llvm-project/libcxx/include/__condition_variable/condition_variable.h:168: DB::DatabaseReplicatedDDLWorker::tryEnqueueAndExecuteEntry(DB::DDLLogEntry&, std::shared_ptr, bool) @ 0x0000000013dc289d 6. /build/src/Databases/DatabaseReplicated.cpp:1139: DB::DatabaseReplicated::tryEnqueueReplicatedDDL(std::shared_ptr const&, std::shared_ptr, DB::QueryFlags) @ 0x0000000013d9f73c 7. /build/src/Interpreters/InterpreterDropQuery.cpp:226: DB::InterpreterDropQuery::executeToTableImpl(std::shared_ptr const&, DB::ASTDropQuery&, std::shared_ptr&, StrongTypedef, DB::UUIDTag>&) @ 0x0000000014914ed7 8. /build/src/Interpreters/InterpreterDropQuery.cpp:118: DB::InterpreterDropQuery::executeToTable(DB::ASTDropQuery&) @ 0x00000000149137b4 9. /build/src/Interpreters/InterpreterDropQuery.cpp:91: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000014912f07 10. /build/src/Interpreters/InterpreterDropQuery.cpp:72: DB::InterpreterDropQuery::execute() @ 0x0000000014912b65 11. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88dc9 12. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 13. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 14. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 15. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 16. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 17. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 18. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 19. ? @ 0x00007fbc6213eac3 20. ? @ 0x00007fbc621d0850 2025.07.28 11:52:01.848772 [ 5951 ] {} TCPHandler: Code: 571. DB::Exception: ZooKeeper session expired or replication stopped, try again. (DATABASE_REPLICATION_FAILED), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000000a074fcb 4. /build/src/Databases/DatabaseReplicatedWorker.cpp:352: DB::DatabaseReplicatedDDLWorker::tryEnqueueAndExecuteEntry(DB::DDLLogEntry&, std::shared_ptr, bool)::$_1::operator()() const @ 0x0000000013dc6b95 5. /build/contrib/llvm-project/libcxx/include/__condition_variable/condition_variable.h:168: DB::DatabaseReplicatedDDLWorker::tryEnqueueAndExecuteEntry(DB::DDLLogEntry&, std::shared_ptr, bool) @ 0x0000000013dc289d 6. /build/src/Databases/DatabaseReplicated.cpp:1139: DB::DatabaseReplicated::tryEnqueueReplicatedDDL(std::shared_ptr const&, std::shared_ptr, DB::QueryFlags) @ 0x0000000013d9f73c 7. /build/src/Interpreters/InterpreterDropQuery.cpp:226: DB::InterpreterDropQuery::executeToTableImpl(std::shared_ptr const&, DB::ASTDropQuery&, std::shared_ptr&, StrongTypedef, DB::UUIDTag>&) @ 0x0000000014914ed7 8. /build/src/Interpreters/InterpreterDropQuery.cpp:118: DB::InterpreterDropQuery::executeToTable(DB::ASTDropQuery&) @ 0x00000000149137b4 9. /build/src/Interpreters/InterpreterDropQuery.cpp:91: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000014912f07 10. /build/src/Interpreters/InterpreterDropQuery.cpp:72: DB::InterpreterDropQuery::execute() @ 0x0000000014912b65 11. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88dc9 12. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 13. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 14. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 15. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 16. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 17. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 18. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 19. ? @ 0x00007fbc6213eac3 20. ? @ 0x00007fbc621d0850 2025.07.28 11:52:01.936764 [ 3965 ] {} test_13.rmt2 (7f9b740d-015c-470e-8cc6-8ba33be0dc63): auto DB::StorageReplicatedMergeTree::processQueueEntry(ReplicatedMergeTreeQueue::SelectedEntryPtr)::(anonymous class)::operator()(LogEntryPtr &) const: Code: 86. DB::HTTPException: Received error from remote server http://146b4357c08d:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Ftest%2F01165%2Ftest_13%2Frmt%2Freplicas%2F1&part=20250728_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.6.10636.altinitytest (altinity build)) '. (RECEIVED_ERROR_FROM_REMOTE_IO_SERVER), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.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 const&, int&&, String const&, unsigned long&&, String const&) @ 0x000000000feda8d9 4. /build/src/IO/HTTPCommon.cpp:104: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x000000000feda6e2 5. /build/src/IO/HTTPCommon.cpp:93: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x000000000feda537 6. /build/src/IO/ReadWriteBufferFromHTTP.cpp:277: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x000000001184a4c4 7. /build/src/IO/ReadWriteBufferFromHTTP.cpp:285: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x000000001184a615 8. /build/src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x000000001184ae59 9. /build/src/IO/ReadWriteBufferFromHTTP.cpp:472: void std::__function::__policy_invoker::__call_impl[abi:se190107]>(std::__function::__policy_storage const*) @ 0x000000001184cedd 10. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001184858b 11. /build/src/IO/ReadWriteBufferFromHTTP.cpp:465: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x000000001184bf0b 12. /build/src/IO/ReadBuffer.h:60: DB::ReadBuffer::next() @ 0x000000000a148c7b 13. /build/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) @ 0x0000000011849fb2 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]>&)>&, 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&) @ 0x0000000011841980 15. /build/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) @ 0x000000001621208e 16. /build/src/Storages/StorageReplicatedMergeTree.cpp:5228: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl[abi:se190107] const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000015f9a5fe 17. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000015ed8bfd 18. /build/src/Storages/StorageReplicatedMergeTree.cpp:2514: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x0000000015ec9aab 19. /build/src/Storages/StorageReplicatedMergeTree.cpp:2349: DB::StorageReplicatedMergeTree::executeLogEntry(DB::ReplicatedMergeTreeLogEntry&) @ 0x0000000015eba91b 20. /build/src/Storages/StorageReplicatedMergeTree.cpp:3876: bool std::__function::__policy_invoker&)>::__call_impl[abi:se190107])::$_1, bool (std::shared_ptr&)>>(std::__function::__policy_storage const*, std::shared_ptr&) @ 0x0000000015f9837e 21. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000165d6fc3 22. /build/src/Storages/StorageReplicatedMergeTree.cpp:3872: DB::StorageReplicatedMergeTree::processQueueEntry(std::shared_ptr) @ 0x0000000015efc18a 23. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001624c1b2 24. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000162f9c70 25. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x00000000162fa55a 26. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc6653 27. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000000fccc4c3 28. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc3d92 29. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fcca080 30. ? @ 0x00007fbc6213eac3 31. ? @ 0x00007fbc621d0850 (version 25.3.6.10636.altinitytest (altinity build)) 2025.07.28 11:52:02.005220 [ 17958 ] {85918916-367c-45f6-ab79-f061105bc67d} executeQuery: Code: 571. DB::Exception: ZooKeeper session expired or replication stopped, try again. (DATABASE_REPLICATION_FAILED) (version 25.3.6.10636.altinitytest (altinity build)) (from [::1]:60778) (comment: 03238_create_or_replace_view_atomically_with_replicated_engine.sh) (query 1, line 1) (in query: CREATE OR REPLACE VIEW test_9_db.test_view AS SELECT 'abcdef'), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000000a074fcb 4. /build/src/Databases/DatabaseReplicatedWorker.cpp:352: DB::DatabaseReplicatedDDLWorker::tryEnqueueAndExecuteEntry(DB::DDLLogEntry&, std::shared_ptr, bool)::$_1::operator()() const @ 0x0000000013dc6b95 5. /build/contrib/llvm-project/libcxx/include/__condition_variable/condition_variable.h:168: DB::DatabaseReplicatedDDLWorker::tryEnqueueAndExecuteEntry(DB::DDLLogEntry&, std::shared_ptr, bool) @ 0x0000000013dc289d 6. /build/src/Databases/DatabaseReplicated.cpp:1139: DB::DatabaseReplicated::tryEnqueueReplicatedDDL(std::shared_ptr const&, std::shared_ptr, DB::QueryFlags) @ 0x0000000013d9f73c 7. /build/src/Interpreters/InterpreterCreateQuery.cpp:1723: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000148f96f8 8. /build/src/Interpreters/InterpreterCreateQuery.cpp:2352: DB::InterpreterCreateQuery::execute() @ 0x0000000014905a41 9. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88dc9 10. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 11. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 12. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 13. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 14. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 16. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 17. ? @ 0x00007fbc6213eac3 18. ? @ 0x00007fbc621d0850 2025.07.28 11:52:02.018001 [ 17270 ] {47ced9d3-0ea8-45e6-a6ac-d791d734fe01} executeQuery: Code: 571. DB::Exception: ZooKeeper session expired or replication stopped, try again. (DATABASE_REPLICATION_FAILED) (version 25.3.6.10636.altinitytest (altinity build)) (from [::1]:60818) (comment: 03238_create_or_replace_view_atomically_with_replicated_engine.sh) (query 1, line 1) (in query: CREATE OR REPLACE VIEW test_9_db.test_view AS SELECT 'abcdef'), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000000a074fcb 4. /build/src/Databases/DatabaseReplicatedWorker.cpp:352: DB::DatabaseReplicatedDDLWorker::tryEnqueueAndExecuteEntry(DB::DDLLogEntry&, std::shared_ptr, bool)::$_1::operator()() const @ 0x0000000013dc6b95 5. /build/contrib/llvm-project/libcxx/include/__condition_variable/condition_variable.h:168: DB::DatabaseReplicatedDDLWorker::tryEnqueueAndExecuteEntry(DB::DDLLogEntry&, std::shared_ptr, bool) @ 0x0000000013dc289d 6. /build/src/Databases/DatabaseReplicated.cpp:1139: DB::DatabaseReplicated::tryEnqueueReplicatedDDL(std::shared_ptr const&, std::shared_ptr, DB::QueryFlags) @ 0x0000000013d9f73c 7. /build/src/Interpreters/InterpreterCreateQuery.cpp:1723: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000148f96f8 8. /build/src/Interpreters/InterpreterCreateQuery.cpp:2352: DB::InterpreterCreateQuery::execute() @ 0x0000000014905a41 9. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88dc9 10. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 11. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 12. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 13. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 14. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 16. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 17. ? @ 0x00007fbc6213eac3 18. ? @ 0x00007fbc621d0850 2025.07.28 11:52:02.021080 [ 17321 ] {6abc52cd-345d-4d20-8948-970c0f70e0a5} executeQuery: Code: 571. DB::Exception: ZooKeeper session expired or replication stopped, try again. (DATABASE_REPLICATION_FAILED) (version 25.3.6.10636.altinitytest (altinity build)) (from [::1]:60840) (comment: 03238_create_or_replace_view_atomically_with_replicated_engine.sh) (query 1, line 1) (in query: CREATE OR REPLACE VIEW test_9_db.test_view AS SELECT 'abcdef'), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000000a074fcb 4. /build/src/Databases/DatabaseReplicatedWorker.cpp:352: DB::DatabaseReplicatedDDLWorker::tryEnqueueAndExecuteEntry(DB::DDLLogEntry&, std::shared_ptr, bool)::$_1::operator()() const @ 0x0000000013dc6b95 5. /build/contrib/llvm-project/libcxx/include/__condition_variable/condition_variable.h:168: DB::DatabaseReplicatedDDLWorker::tryEnqueueAndExecuteEntry(DB::DDLLogEntry&, std::shared_ptr, bool) @ 0x0000000013dc289d 6. /build/src/Databases/DatabaseReplicated.cpp:1139: DB::DatabaseReplicated::tryEnqueueReplicatedDDL(std::shared_ptr const&, std::shared_ptr, DB::QueryFlags) @ 0x0000000013d9f73c 7. /build/src/Interpreters/InterpreterCreateQuery.cpp:1723: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000148f96f8 8. /build/src/Interpreters/InterpreterCreateQuery.cpp:2352: DB::InterpreterCreateQuery::execute() @ 0x0000000014905a41 9. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88dc9 10. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 11. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 12. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 13. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 14. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 16. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 17. ? @ 0x00007fbc6213eac3 18. ? @ 0x00007fbc621d0850 2025.07.28 11:52:02.022231 [ 17261 ] {a8389537-3ecf-46ed-9418-be86b34f5a04} executeQuery: Code: 571. DB::Exception: ZooKeeper session expired or replication stopped, try again. (DATABASE_REPLICATION_FAILED) (version 25.3.6.10636.altinitytest (altinity build)) (from [::1]:60812) (comment: 03238_create_or_replace_view_atomically_with_replicated_engine.sh) (query 1, line 1) (in query: CREATE OR REPLACE VIEW test_9_db.test_view AS SELECT 'abcdef'), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000000a074fcb 4. /build/src/Databases/DatabaseReplicatedWorker.cpp:352: DB::DatabaseReplicatedDDLWorker::tryEnqueueAndExecuteEntry(DB::DDLLogEntry&, std::shared_ptr, bool)::$_1::operator()() const @ 0x0000000013dc6b95 5. /build/contrib/llvm-project/libcxx/include/__condition_variable/condition_variable.h:168: DB::DatabaseReplicatedDDLWorker::tryEnqueueAndExecuteEntry(DB::DDLLogEntry&, std::shared_ptr, bool) @ 0x0000000013dc289d 6. /build/src/Databases/DatabaseReplicated.cpp:1139: DB::DatabaseReplicated::tryEnqueueReplicatedDDL(std::shared_ptr const&, std::shared_ptr, DB::QueryFlags) @ 0x0000000013d9f73c 7. /build/src/Interpreters/InterpreterCreateQuery.cpp:1723: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000148f96f8 8. /build/src/Interpreters/InterpreterCreateQuery.cpp:2352: DB::InterpreterCreateQuery::execute() @ 0x0000000014905a41 9. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88dc9 10. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 11. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 12. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 13. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 14. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 16. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 17. ? @ 0x00007fbc6213eac3 18. ? @ 0x00007fbc621d0850 2025.07.28 11:52:02.026033 [ 17958 ] {} TCPHandler: Code: 571. DB::Exception: ZooKeeper session expired or replication stopped, try again. (DATABASE_REPLICATION_FAILED), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000000a074fcb 4. /build/src/Databases/DatabaseReplicatedWorker.cpp:352: DB::DatabaseReplicatedDDLWorker::tryEnqueueAndExecuteEntry(DB::DDLLogEntry&, std::shared_ptr, bool)::$_1::operator()() const @ 0x0000000013dc6b95 5. /build/contrib/llvm-project/libcxx/include/__condition_variable/condition_variable.h:168: DB::DatabaseReplicatedDDLWorker::tryEnqueueAndExecuteEntry(DB::DDLLogEntry&, std::shared_ptr, bool) @ 0x0000000013dc289d 6. /build/src/Databases/DatabaseReplicated.cpp:1139: DB::DatabaseReplicated::tryEnqueueReplicatedDDL(std::shared_ptr const&, std::shared_ptr, DB::QueryFlags) @ 0x0000000013d9f73c 7. /build/src/Interpreters/InterpreterCreateQuery.cpp:1723: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000148f96f8 8. /build/src/Interpreters/InterpreterCreateQuery.cpp:2352: DB::InterpreterCreateQuery::execute() @ 0x0000000014905a41 9. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88dc9 10. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 11. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 12. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 13. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 14. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 16. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 17. ? @ 0x00007fbc6213eac3 18. ? @ 0x00007fbc621d0850 2025.07.28 11:52:02.037714 [ 17321 ] {} TCPHandler: Code: 571. DB::Exception: ZooKeeper session expired or replication stopped, try again. (DATABASE_REPLICATION_FAILED), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000000a074fcb 4. /build/src/Databases/DatabaseReplicatedWorker.cpp:352: DB::DatabaseReplicatedDDLWorker::tryEnqueueAndExecuteEntry(DB::DDLLogEntry&, std::shared_ptr, bool)::$_1::operator()() const @ 0x0000000013dc6b95 5. /build/contrib/llvm-project/libcxx/include/__condition_variable/condition_variable.h:168: DB::DatabaseReplicatedDDLWorker::tryEnqueueAndExecuteEntry(DB::DDLLogEntry&, std::shared_ptr, bool) @ 0x0000000013dc289d 6. /build/src/Databases/DatabaseReplicated.cpp:1139: DB::DatabaseReplicated::tryEnqueueReplicatedDDL(std::shared_ptr const&, std::shared_ptr, DB::QueryFlags) @ 0x0000000013d9f73c 7. /build/src/Interpreters/InterpreterCreateQuery.cpp:1723: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000148f96f8 8. /build/src/Interpreters/InterpreterCreateQuery.cpp:2352: DB::InterpreterCreateQuery::execute() @ 0x0000000014905a41 9. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88dc9 10. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 11. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 12. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 13. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 14. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 16. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 17. ? @ 0x00007fbc6213eac3 18. ? @ 0x00007fbc621d0850 2025.07.28 11:52:02.038014 [ 17270 ] {} TCPHandler: Code: 571. DB::Exception: ZooKeeper session expired or replication stopped, try again. (DATABASE_REPLICATION_FAILED), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000000a074fcb 4. /build/src/Databases/DatabaseReplicatedWorker.cpp:352: DB::DatabaseReplicatedDDLWorker::tryEnqueueAndExecuteEntry(DB::DDLLogEntry&, std::shared_ptr, bool)::$_1::operator()() const @ 0x0000000013dc6b95 5. /build/contrib/llvm-project/libcxx/include/__condition_variable/condition_variable.h:168: DB::DatabaseReplicatedDDLWorker::tryEnqueueAndExecuteEntry(DB::DDLLogEntry&, std::shared_ptr, bool) @ 0x0000000013dc289d 6. /build/src/Databases/DatabaseReplicated.cpp:1139: DB::DatabaseReplicated::tryEnqueueReplicatedDDL(std::shared_ptr const&, std::shared_ptr, DB::QueryFlags) @ 0x0000000013d9f73c 7. /build/src/Interpreters/InterpreterCreateQuery.cpp:1723: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000148f96f8 8. /build/src/Interpreters/InterpreterCreateQuery.cpp:2352: DB::InterpreterCreateQuery::execute() @ 0x0000000014905a41 9. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88dc9 10. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 11. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 12. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 13. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 14. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 16. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 17. ? @ 0x00007fbc6213eac3 18. ? @ 0x00007fbc621d0850 2025.07.28 11:52:02.044471 [ 11851 ] {e3be9c9f-e7ed-44c5-afea-92301107e562} executeQuery: Code: 571. DB::Exception: ZooKeeper session expired or replication stopped, try again. (DATABASE_REPLICATION_FAILED) (version 25.3.6.10636.altinitytest (altinity build)) (from [::1]:60850) (comment: 03238_create_or_replace_view_atomically_with_replicated_engine.sh) (query 1, line 1) (in query: CREATE OR REPLACE VIEW test_9_db.test_view AS SELECT 'abcdef'), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000000a074fcb 4. /build/src/Databases/DatabaseReplicatedWorker.cpp:352: DB::DatabaseReplicatedDDLWorker::tryEnqueueAndExecuteEntry(DB::DDLLogEntry&, std::shared_ptr, bool)::$_1::operator()() const @ 0x0000000013dc6b95 5. /build/contrib/llvm-project/libcxx/include/__condition_variable/condition_variable.h:168: DB::DatabaseReplicatedDDLWorker::tryEnqueueAndExecuteEntry(DB::DDLLogEntry&, std::shared_ptr, bool) @ 0x0000000013dc289d 6. /build/src/Databases/DatabaseReplicated.cpp:1139: DB::DatabaseReplicated::tryEnqueueReplicatedDDL(std::shared_ptr const&, std::shared_ptr, DB::QueryFlags) @ 0x0000000013d9f73c 7. /build/src/Interpreters/InterpreterCreateQuery.cpp:1723: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000148f96f8 8. /build/src/Interpreters/InterpreterCreateQuery.cpp:2352: DB::InterpreterCreateQuery::execute() @ 0x0000000014905a41 9. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88dc9 10. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 11. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 12. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 13. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 14. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 16. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 17. ? @ 0x00007fbc6213eac3 18. ? @ 0x00007fbc621d0850 2025.07.28 11:52:02.044531 [ 17557 ] {91631b92-572d-4429-9dab-928f98e5c795} executeQuery: Code: 571. DB::Exception: ZooKeeper session expired or replication stopped, try again. (DATABASE_REPLICATION_FAILED) (version 25.3.6.10636.altinitytest (altinity build)) (from [::1]:60854) (comment: 03238_create_or_replace_view_atomically_with_replicated_engine.sh) (query 1, line 1) (in query: CREATE OR REPLACE VIEW test_9_db.test_view AS SELECT 'abcdef'), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000000a074fcb 4. /build/src/Databases/DatabaseReplicatedWorker.cpp:352: DB::DatabaseReplicatedDDLWorker::tryEnqueueAndExecuteEntry(DB::DDLLogEntry&, std::shared_ptr, bool)::$_1::operator()() const @ 0x0000000013dc6b95 5. /build/contrib/llvm-project/libcxx/include/__condition_variable/condition_variable.h:168: DB::DatabaseReplicatedDDLWorker::tryEnqueueAndExecuteEntry(DB::DDLLogEntry&, std::shared_ptr, bool) @ 0x0000000013dc289d 6. /build/src/Databases/DatabaseReplicated.cpp:1139: DB::DatabaseReplicated::tryEnqueueReplicatedDDL(std::shared_ptr const&, std::shared_ptr, DB::QueryFlags) @ 0x0000000013d9f73c 7. /build/src/Interpreters/InterpreterCreateQuery.cpp:1723: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000148f96f8 8. /build/src/Interpreters/InterpreterCreateQuery.cpp:2352: DB::InterpreterCreateQuery::execute() @ 0x0000000014905a41 9. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88dc9 10. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 11. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 12. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 13. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 14. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 16. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 17. ? @ 0x00007fbc6213eac3 18. ? @ 0x00007fbc621d0850 2025.07.28 11:52:02.047910 [ 17261 ] {} TCPHandler: Code: 571. DB::Exception: ZooKeeper session expired or replication stopped, try again. (DATABASE_REPLICATION_FAILED), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000000a074fcb 4. /build/src/Databases/DatabaseReplicatedWorker.cpp:352: DB::DatabaseReplicatedDDLWorker::tryEnqueueAndExecuteEntry(DB::DDLLogEntry&, std::shared_ptr, bool)::$_1::operator()() const @ 0x0000000013dc6b95 5. /build/contrib/llvm-project/libcxx/include/__condition_variable/condition_variable.h:168: DB::DatabaseReplicatedDDLWorker::tryEnqueueAndExecuteEntry(DB::DDLLogEntry&, std::shared_ptr, bool) @ 0x0000000013dc289d 6. /build/src/Databases/DatabaseReplicated.cpp:1139: DB::DatabaseReplicated::tryEnqueueReplicatedDDL(std::shared_ptr const&, std::shared_ptr, DB::QueryFlags) @ 0x0000000013d9f73c 7. /build/src/Interpreters/InterpreterCreateQuery.cpp:1723: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000148f96f8 8. /build/src/Interpreters/InterpreterCreateQuery.cpp:2352: DB::InterpreterCreateQuery::execute() @ 0x0000000014905a41 9. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88dc9 10. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 11. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 12. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 13. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 14. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 16. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 17. ? @ 0x00007fbc6213eac3 18. ? @ 0x00007fbc621d0850 2025.07.28 11:52:02.054919 [ 17287 ] {eb0350a7-e154-45af-ad7e-a470f93b437c} executeQuery: Code: 571. DB::Exception: ZooKeeper session expired or replication stopped, try again. (DATABASE_REPLICATION_FAILED) (version 25.3.6.10636.altinitytest (altinity build)) (from [::1]:60722) (comment: 03238_create_or_replace_view_atomically_with_replicated_engine.sh) (query 1, line 1) (in query: CREATE OR REPLACE VIEW test_9_db.test_view AS SELECT 'abcdef'), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000000a074fcb 4. /build/src/Databases/DatabaseReplicatedWorker.cpp:352: DB::DatabaseReplicatedDDLWorker::tryEnqueueAndExecuteEntry(DB::DDLLogEntry&, std::shared_ptr, bool)::$_1::operator()() const @ 0x0000000013dc6b95 5. /build/contrib/llvm-project/libcxx/include/__condition_variable/condition_variable.h:168: DB::DatabaseReplicatedDDLWorker::tryEnqueueAndExecuteEntry(DB::DDLLogEntry&, std::shared_ptr, bool) @ 0x0000000013dc289d 6. /build/src/Databases/DatabaseReplicated.cpp:1139: DB::DatabaseReplicated::tryEnqueueReplicatedDDL(std::shared_ptr const&, std::shared_ptr, DB::QueryFlags) @ 0x0000000013d9f73c 7. /build/src/Interpreters/InterpreterCreateQuery.cpp:1723: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000148f96f8 8. /build/src/Interpreters/InterpreterCreateQuery.cpp:2352: DB::InterpreterCreateQuery::execute() @ 0x0000000014905a41 9. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88dc9 10. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 11. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 12. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 13. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 14. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 16. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 17. ? @ 0x00007fbc6213eac3 18. ? @ 0x00007fbc621d0850 2025.07.28 11:52:02.063271 [ 11851 ] {} TCPHandler: Code: 571. DB::Exception: ZooKeeper session expired or replication stopped, try again. (DATABASE_REPLICATION_FAILED), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000000a074fcb 4. /build/src/Databases/DatabaseReplicatedWorker.cpp:352: DB::DatabaseReplicatedDDLWorker::tryEnqueueAndExecuteEntry(DB::DDLLogEntry&, std::shared_ptr, bool)::$_1::operator()() const @ 0x0000000013dc6b95 5. /build/contrib/llvm-project/libcxx/include/__condition_variable/condition_variable.h:168: DB::DatabaseReplicatedDDLWorker::tryEnqueueAndExecuteEntry(DB::DDLLogEntry&, std::shared_ptr, bool) @ 0x0000000013dc289d 6. /build/src/Databases/DatabaseReplicated.cpp:1139: DB::DatabaseReplicated::tryEnqueueReplicatedDDL(std::shared_ptr const&, std::shared_ptr, DB::QueryFlags) @ 0x0000000013d9f73c 7. /build/src/Interpreters/InterpreterCreateQuery.cpp:1723: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000148f96f8 8. /build/src/Interpreters/InterpreterCreateQuery.cpp:2352: DB::InterpreterCreateQuery::execute() @ 0x0000000014905a41 9. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88dc9 10. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 11. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 12. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 13. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 14. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 16. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 17. ? @ 0x00007fbc6213eac3 18. ? @ 0x00007fbc621d0850 2025.07.28 11:52:02.063835 [ 17557 ] {} TCPHandler: Code: 571. DB::Exception: ZooKeeper session expired or replication stopped, try again. (DATABASE_REPLICATION_FAILED), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000000a074fcb 4. /build/src/Databases/DatabaseReplicatedWorker.cpp:352: DB::DatabaseReplicatedDDLWorker::tryEnqueueAndExecuteEntry(DB::DDLLogEntry&, std::shared_ptr, bool)::$_1::operator()() const @ 0x0000000013dc6b95 5. /build/contrib/llvm-project/libcxx/include/__condition_variable/condition_variable.h:168: DB::DatabaseReplicatedDDLWorker::tryEnqueueAndExecuteEntry(DB::DDLLogEntry&, std::shared_ptr, bool) @ 0x0000000013dc289d 6. /build/src/Databases/DatabaseReplicated.cpp:1139: DB::DatabaseReplicated::tryEnqueueReplicatedDDL(std::shared_ptr const&, std::shared_ptr, DB::QueryFlags) @ 0x0000000013d9f73c 7. /build/src/Interpreters/InterpreterCreateQuery.cpp:1723: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000148f96f8 8. /build/src/Interpreters/InterpreterCreateQuery.cpp:2352: DB::InterpreterCreateQuery::execute() @ 0x0000000014905a41 9. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88dc9 10. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 11. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 12. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 13. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 14. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 16. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 17. ? @ 0x00007fbc6213eac3 18. ? @ 0x00007fbc621d0850 2025.07.28 11:52:02.071921 [ 17287 ] {} TCPHandler: Code: 571. DB::Exception: ZooKeeper session expired or replication stopped, try again. (DATABASE_REPLICATION_FAILED), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000000a074fcb 4. /build/src/Databases/DatabaseReplicatedWorker.cpp:352: DB::DatabaseReplicatedDDLWorker::tryEnqueueAndExecuteEntry(DB::DDLLogEntry&, std::shared_ptr, bool)::$_1::operator()() const @ 0x0000000013dc6b95 5. /build/contrib/llvm-project/libcxx/include/__condition_variable/condition_variable.h:168: DB::DatabaseReplicatedDDLWorker::tryEnqueueAndExecuteEntry(DB::DDLLogEntry&, std::shared_ptr, bool) @ 0x0000000013dc289d 6. /build/src/Databases/DatabaseReplicated.cpp:1139: DB::DatabaseReplicated::tryEnqueueReplicatedDDL(std::shared_ptr const&, std::shared_ptr, DB::QueryFlags) @ 0x0000000013d9f73c 7. /build/src/Interpreters/InterpreterCreateQuery.cpp:1723: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000148f96f8 8. /build/src/Interpreters/InterpreterCreateQuery.cpp:2352: DB::InterpreterCreateQuery::execute() @ 0x0000000014905a41 9. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88dc9 10. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 11. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 12. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 13. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 14. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 16. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 17. ? @ 0x00007fbc6213eac3 18. ? @ 0x00007fbc621d0850 2025.07.28 11:52:02.085878 [ 3974 ] {} test_13.rmt2 (7f9b740d-015c-470e-8cc6-8ba33be0dc63): auto DB::StorageReplicatedMergeTree::processQueueEntry(ReplicatedMergeTreeQueue::SelectedEntryPtr)::(anonymous class)::operator()(LogEntryPtr &) const: Code: 86. DB::HTTPException: Received error from remote server http://146b4357c08d:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Ftest%2F01165%2Ftest_13%2Frmt%2Freplicas%2F1&part=20250728_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.6.10636.altinitytest (altinity build)) '. (RECEIVED_ERROR_FROM_REMOTE_IO_SERVER), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.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 const&, int&&, String const&, unsigned long&&, String const&) @ 0x000000000feda8d9 4. /build/src/IO/HTTPCommon.cpp:104: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x000000000feda6e2 5. /build/src/IO/HTTPCommon.cpp:93: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x000000000feda537 6. /build/src/IO/ReadWriteBufferFromHTTP.cpp:277: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x000000001184a4c4 7. /build/src/IO/ReadWriteBufferFromHTTP.cpp:285: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x000000001184a615 8. /build/src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x000000001184ae59 9. /build/src/IO/ReadWriteBufferFromHTTP.cpp:472: void std::__function::__policy_invoker::__call_impl[abi:se190107]>(std::__function::__policy_storage const*) @ 0x000000001184cedd 10. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001184858b 11. /build/src/IO/ReadWriteBufferFromHTTP.cpp:465: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x000000001184bf0b 12. /build/src/IO/ReadBuffer.h:60: DB::ReadBuffer::next() @ 0x000000000a148c7b 13. /build/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) @ 0x0000000011849fb2 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]>&)>&, 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&) @ 0x0000000011841980 15. /build/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) @ 0x000000001621208e 16. /build/src/Storages/StorageReplicatedMergeTree.cpp:5228: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl[abi:se190107] const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000015f9a5fe 17. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000015ed8bfd 18. /build/src/Storages/StorageReplicatedMergeTree.cpp:2514: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x0000000015ec9aab 19. /build/src/Storages/StorageReplicatedMergeTree.cpp:2349: DB::StorageReplicatedMergeTree::executeLogEntry(DB::ReplicatedMergeTreeLogEntry&) @ 0x0000000015eba91b 20. /build/src/Storages/StorageReplicatedMergeTree.cpp:3876: bool std::__function::__policy_invoker&)>::__call_impl[abi:se190107])::$_1, bool (std::shared_ptr&)>>(std::__function::__policy_storage const*, std::shared_ptr&) @ 0x0000000015f9837e 21. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000165d6fc3 22. /build/src/Storages/StorageReplicatedMergeTree.cpp:3872: DB::StorageReplicatedMergeTree::processQueueEntry(std::shared_ptr) @ 0x0000000015efc18a 23. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001624c1b2 24. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000162f9c70 25. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x00000000162fa55a 26. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc6653 27. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000000fccc4c3 28. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc3d92 29. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fcca080 30. ? @ 0x00007fbc6213eac3 31. ? @ 0x00007fbc621d0850 (version 25.3.6.10636.altinitytest (altinity build)) 2025.07.28 11:52:02.090396 [ 17255 ] {18430aec-5cd8-4337-a396-4de7bc69645c} executeQuery: Code: 571. DB::Exception: ZooKeeper session expired or replication stopped, try again. (DATABASE_REPLICATION_FAILED) (version 25.3.6.10636.altinitytest (altinity build)) (from [::1]:60750) (comment: 03238_create_or_replace_view_atomically_with_replicated_engine.sh) (query 1, line 1) (in query: CREATE OR REPLACE VIEW test_9_db.test_view AS SELECT 'abcdef'), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000000a074fcb 4. /build/src/Databases/DatabaseReplicatedWorker.cpp:352: DB::DatabaseReplicatedDDLWorker::tryEnqueueAndExecuteEntry(DB::DDLLogEntry&, std::shared_ptr, bool)::$_1::operator()() const @ 0x0000000013dc6b95 5. /build/contrib/llvm-project/libcxx/include/__condition_variable/condition_variable.h:168: DB::DatabaseReplicatedDDLWorker::tryEnqueueAndExecuteEntry(DB::DDLLogEntry&, std::shared_ptr, bool) @ 0x0000000013dc289d 6. /build/src/Databases/DatabaseReplicated.cpp:1139: DB::DatabaseReplicated::tryEnqueueReplicatedDDL(std::shared_ptr const&, std::shared_ptr, DB::QueryFlags) @ 0x0000000013d9f73c 7. /build/src/Interpreters/InterpreterCreateQuery.cpp:1723: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000148f96f8 8. /build/src/Interpreters/InterpreterCreateQuery.cpp:2352: DB::InterpreterCreateQuery::execute() @ 0x0000000014905a41 9. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88dc9 10. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 11. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 12. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 13. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 14. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 16. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 17. ? @ 0x00007fbc6213eac3 18. ? @ 0x00007fbc621d0850 2025.07.28 11:52:02.121679 [ 17255 ] {} TCPHandler: Code: 571. DB::Exception: ZooKeeper session expired or replication stopped, try again. (DATABASE_REPLICATION_FAILED), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000000a074fcb 4. /build/src/Databases/DatabaseReplicatedWorker.cpp:352: DB::DatabaseReplicatedDDLWorker::tryEnqueueAndExecuteEntry(DB::DDLLogEntry&, std::shared_ptr, bool)::$_1::operator()() const @ 0x0000000013dc6b95 5. /build/contrib/llvm-project/libcxx/include/__condition_variable/condition_variable.h:168: DB::DatabaseReplicatedDDLWorker::tryEnqueueAndExecuteEntry(DB::DDLLogEntry&, std::shared_ptr, bool) @ 0x0000000013dc289d 6. /build/src/Databases/DatabaseReplicated.cpp:1139: DB::DatabaseReplicated::tryEnqueueReplicatedDDL(std::shared_ptr const&, std::shared_ptr, DB::QueryFlags) @ 0x0000000013d9f73c 7. /build/src/Interpreters/InterpreterCreateQuery.cpp:1723: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000148f96f8 8. /build/src/Interpreters/InterpreterCreateQuery.cpp:2352: DB::InterpreterCreateQuery::execute() @ 0x0000000014905a41 9. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88dc9 10. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 11. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 12. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 13. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 14. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 16. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 17. ? @ 0x00007fbc6213eac3 18. ? @ 0x00007fbc621d0850 2025.07.28 11:52:03.005140 [ 3964 ] {} test_13.rmt2 (7f9b740d-015c-470e-8cc6-8ba33be0dc63): auto DB::StorageReplicatedMergeTree::processQueueEntry(ReplicatedMergeTreeQueue::SelectedEntryPtr)::(anonymous class)::operator()(LogEntryPtr &) const: Code: 86. DB::HTTPException: Received error from remote server http://146b4357c08d:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Ftest%2F01165%2Ftest_13%2Frmt%2Freplicas%2F1&part=20250728_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.6.10636.altinitytest (altinity build)) '. (RECEIVED_ERROR_FROM_REMOTE_IO_SERVER), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.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 const&, int&&, String const&, unsigned long&&, String const&) @ 0x000000000feda8d9 4. /build/src/IO/HTTPCommon.cpp:104: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x000000000feda6e2 5. /build/src/IO/HTTPCommon.cpp:93: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x000000000feda537 6. /build/src/IO/ReadWriteBufferFromHTTP.cpp:277: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x000000001184a4c4 7. /build/src/IO/ReadWriteBufferFromHTTP.cpp:285: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x000000001184a615 8. /build/src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x000000001184ae59 9. /build/src/IO/ReadWriteBufferFromHTTP.cpp:472: void std::__function::__policy_invoker::__call_impl[abi:se190107]>(std::__function::__policy_storage const*) @ 0x000000001184cedd 10. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001184858b 11. /build/src/IO/ReadWriteBufferFromHTTP.cpp:465: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x000000001184bf0b 12. /build/src/IO/ReadBuffer.h:60: DB::ReadBuffer::next() @ 0x000000000a148c7b 13. /build/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) @ 0x0000000011849fb2 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]>&)>&, 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&) @ 0x0000000011841980 15. /build/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) @ 0x000000001621208e 16. /build/src/Storages/StorageReplicatedMergeTree.cpp:5228: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl[abi:se190107] const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000015f9a5fe 17. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000015ed8bfd 18. /build/src/Storages/StorageReplicatedMergeTree.cpp:2514: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x0000000015ec9aab 19. /build/src/Storages/StorageReplicatedMergeTree.cpp:2349: DB::StorageReplicatedMergeTree::executeLogEntry(DB::ReplicatedMergeTreeLogEntry&) @ 0x0000000015eba91b 20. /build/src/Storages/StorageReplicatedMergeTree.cpp:3876: bool std::__function::__policy_invoker&)>::__call_impl[abi:se190107])::$_1, bool (std::shared_ptr&)>>(std::__function::__policy_storage const*, std::shared_ptr&) @ 0x0000000015f9837e 21. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000165d6fc3 22. /build/src/Storages/StorageReplicatedMergeTree.cpp:3872: DB::StorageReplicatedMergeTree::processQueueEntry(std::shared_ptr) @ 0x0000000015efc18a 23. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001624c1b2 24. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000162f9c70 25. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x00000000162fa55a 26. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc6653 27. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000000fccc4c3 28. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc3d92 29. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fcca080 30. ? @ 0x00007fbc6213eac3 31. ? @ 0x00007fbc621d0850 (version 25.3.6.10636.altinitytest (altinity build)) 2025.07.28 11:52:03.447465 [ 3960 ] {} test_13.rmt2 (7f9b740d-015c-470e-8cc6-8ba33be0dc63): auto DB::StorageReplicatedMergeTree::processQueueEntry(ReplicatedMergeTreeQueue::SelectedEntryPtr)::(anonymous class)::operator()(LogEntryPtr &) const: Code: 86. DB::HTTPException: Received error from remote server http://146b4357c08d:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Ftest%2F01165%2Ftest_13%2Frmt%2Freplicas%2F1&part=20250728_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.6.10636.altinitytest (altinity build)) '. (RECEIVED_ERROR_FROM_REMOTE_IO_SERVER), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.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 const&, int&&, String const&, unsigned long&&, String const&) @ 0x000000000feda8d9 4. /build/src/IO/HTTPCommon.cpp:104: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x000000000feda6e2 5. /build/src/IO/HTTPCommon.cpp:93: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x000000000feda537 6. /build/src/IO/ReadWriteBufferFromHTTP.cpp:277: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x000000001184a4c4 7. /build/src/IO/ReadWriteBufferFromHTTP.cpp:285: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x000000001184a615 8. /build/src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x000000001184ae59 9. /build/src/IO/ReadWriteBufferFromHTTP.cpp:472: void std::__function::__policy_invoker::__call_impl[abi:se190107]>(std::__function::__policy_storage const*) @ 0x000000001184cedd 10. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001184858b 11. /build/src/IO/ReadWriteBufferFromHTTP.cpp:465: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x000000001184bf0b 12. /build/src/IO/ReadBuffer.h:60: DB::ReadBuffer::next() @ 0x000000000a148c7b 13. /build/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) @ 0x0000000011849fb2 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]>&)>&, 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&) @ 0x0000000011841980 15. /build/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) @ 0x000000001621208e 16. /build/src/Storages/StorageReplicatedMergeTree.cpp:5228: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl[abi:se190107] const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000015f9a5fe 17. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000015ed8bfd 18. /build/src/Storages/StorageReplicatedMergeTree.cpp:2514: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x0000000015ec9aab 19. /build/src/Storages/StorageReplicatedMergeTree.cpp:2349: DB::StorageReplicatedMergeTree::executeLogEntry(DB::ReplicatedMergeTreeLogEntry&) @ 0x0000000015eba91b 20. /build/src/Storages/StorageReplicatedMergeTree.cpp:3876: bool std::__function::__policy_invoker&)>::__call_impl[abi:se190107])::$_1, bool (std::shared_ptr&)>>(std::__function::__policy_storage const*, std::shared_ptr&) @ 0x0000000015f9837e 21. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000165d6fc3 22. /build/src/Storages/StorageReplicatedMergeTree.cpp:3872: DB::StorageReplicatedMergeTree::processQueueEntry(std::shared_ptr) @ 0x0000000015efc18a 23. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001624c1b2 24. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000162f9c70 25. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x00000000162fa55a 26. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc6653 27. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000000fccc4c3 28. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc3d92 29. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fcca080 30. ? @ 0x00007fbc6213eac3 31. ? @ 0x00007fbc621d0850 (version 25.3.6.10636.altinitytest (altinity build)) 2025.07.28 11:52:03.699723 [ 3967 ] {} test_13.rmt2 (7f9b740d-015c-470e-8cc6-8ba33be0dc63): auto DB::StorageReplicatedMergeTree::processQueueEntry(ReplicatedMergeTreeQueue::SelectedEntryPtr)::(anonymous class)::operator()(LogEntryPtr &) const: Code: 86. DB::HTTPException: Received error from remote server http://146b4357c08d:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Ftest%2F01165%2Ftest_13%2Frmt%2Freplicas%2F1&part=20250728_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.6.10636.altinitytest (altinity build)) '. (RECEIVED_ERROR_FROM_REMOTE_IO_SERVER), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.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 const&, int&&, String const&, unsigned long&&, String const&) @ 0x000000000feda8d9 4. /build/src/IO/HTTPCommon.cpp:104: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x000000000feda6e2 5. /build/src/IO/HTTPCommon.cpp:93: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x000000000feda537 6. /build/src/IO/ReadWriteBufferFromHTTP.cpp:277: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x000000001184a4c4 7. /build/src/IO/ReadWriteBufferFromHTTP.cpp:285: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x000000001184a615 8. /build/src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x000000001184ae59 9. /build/src/IO/ReadWriteBufferFromHTTP.cpp:472: void std::__function::__policy_invoker::__call_impl[abi:se190107]>(std::__function::__policy_storage const*) @ 0x000000001184cedd 10. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001184858b 11. /build/src/IO/ReadWriteBufferFromHTTP.cpp:465: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x000000001184bf0b 12. /build/src/IO/ReadBuffer.h:60: DB::ReadBuffer::next() @ 0x000000000a148c7b 13. /build/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) @ 0x0000000011849fb2 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]>&)>&, 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&) @ 0x0000000011841980 15. /build/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) @ 0x000000001621208e 16. /build/src/Storages/StorageReplicatedMergeTree.cpp:5228: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl[abi:se190107] const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000015f9a5fe 17. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000015ed8bfd 18. /build/src/Storages/StorageReplicatedMergeTree.cpp:2514: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x0000000015ec9aab 19. /build/src/Storages/StorageReplicatedMergeTree.cpp:2349: DB::StorageReplicatedMergeTree::executeLogEntry(DB::ReplicatedMergeTreeLogEntry&) @ 0x0000000015eba91b 20. /build/src/Storages/StorageReplicatedMergeTree.cpp:3876: bool std::__function::__policy_invoker&)>::__call_impl[abi:se190107])::$_1, bool (std::shared_ptr&)>>(std::__function::__policy_storage const*, std::shared_ptr&) @ 0x0000000015f9837e 21. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000165d6fc3 22. /build/src/Storages/StorageReplicatedMergeTree.cpp:3872: DB::StorageReplicatedMergeTree::processQueueEntry(std::shared_ptr) @ 0x0000000015efc18a 23. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001624c1b2 24. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000162f9c70 25. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x00000000162fa55a 26. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc6653 27. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000000fccc4c3 28. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc3d92 29. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fcca080 30. ? @ 0x00007fbc6213eac3 31. ? @ 0x00007fbc621d0850 (version 25.3.6.10636.altinitytest (altinity build)) 2025.07.28 11:52:03.970016 [ 3965 ] {} test_13.rmt2 (7f9b740d-015c-470e-8cc6-8ba33be0dc63): auto DB::StorageReplicatedMergeTree::processQueueEntry(ReplicatedMergeTreeQueue::SelectedEntryPtr)::(anonymous class)::operator()(LogEntryPtr &) const: Code: 86. DB::HTTPException: Received error from remote server http://146b4357c08d:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Ftest%2F01165%2Ftest_13%2Frmt%2Freplicas%2F1&part=20250728_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.6.10636.altinitytest (altinity build)) '. (RECEIVED_ERROR_FROM_REMOTE_IO_SERVER), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.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 const&, int&&, String const&, unsigned long&&, String const&) @ 0x000000000feda8d9 4. /build/src/IO/HTTPCommon.cpp:104: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x000000000feda6e2 5. /build/src/IO/HTTPCommon.cpp:93: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x000000000feda537 6. /build/src/IO/ReadWriteBufferFromHTTP.cpp:277: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x000000001184a4c4 7. /build/src/IO/ReadWriteBufferFromHTTP.cpp:285: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x000000001184a615 8. /build/src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x000000001184ae59 9. /build/src/IO/ReadWriteBufferFromHTTP.cpp:472: void std::__function::__policy_invoker::__call_impl[abi:se190107]>(std::__function::__policy_storage const*) @ 0x000000001184cedd 10. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001184858b 11. /build/src/IO/ReadWriteBufferFromHTTP.cpp:465: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x000000001184bf0b 12. /build/src/IO/ReadBuffer.h:60: DB::ReadBuffer::next() @ 0x000000000a148c7b 13. /build/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) @ 0x0000000011849fb2 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]>&)>&, 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&) @ 0x0000000011841980 15. /build/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) @ 0x000000001621208e 16. /build/src/Storages/StorageReplicatedMergeTree.cpp:5228: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl[abi:se190107] const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000015f9a5fe 17. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000015ed8bfd 18. /build/src/Storages/StorageReplicatedMergeTree.cpp:2514: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x0000000015ec9aab 19. /build/src/Storages/StorageReplicatedMergeTree.cpp:2349: DB::StorageReplicatedMergeTree::executeLogEntry(DB::ReplicatedMergeTreeLogEntry&) @ 0x0000000015eba91b 20. /build/src/Storages/StorageReplicatedMergeTree.cpp:3876: bool std::__function::__policy_invoker&)>::__call_impl[abi:se190107])::$_1, bool (std::shared_ptr&)>>(std::__function::__policy_storage const*, std::shared_ptr&) @ 0x0000000015f9837e 21. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000165d6fc3 22. /build/src/Storages/StorageReplicatedMergeTree.cpp:3872: DB::StorageReplicatedMergeTree::processQueueEntry(std::shared_ptr) @ 0x0000000015efc18a 23. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001624c1b2 24. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000162f9c70 25. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x00000000162fa55a 26. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc6653 27. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000000fccc4c3 28. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc3d92 29. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fcca080 30. ? @ 0x00007fbc6213eac3 31. ? @ 0x00007fbc621d0850 (version 25.3.6.10636.altinitytest (altinity build)) 2025.07.28 11:52:04.338173 [ 3963 ] {} test_13.rmt2 (7f9b740d-015c-470e-8cc6-8ba33be0dc63): auto DB::StorageReplicatedMergeTree::processQueueEntry(ReplicatedMergeTreeQueue::SelectedEntryPtr)::(anonymous class)::operator()(LogEntryPtr &) const: Code: 86. DB::HTTPException: Received error from remote server http://146b4357c08d:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Ftest%2F01165%2Ftest_13%2Frmt%2Freplicas%2F1&part=20250728_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.6.10636.altinitytest (altinity build)) '. (RECEIVED_ERROR_FROM_REMOTE_IO_SERVER), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.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 const&, int&&, String const&, unsigned long&&, String const&) @ 0x000000000feda8d9 4. /build/src/IO/HTTPCommon.cpp:104: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x000000000feda6e2 5. /build/src/IO/HTTPCommon.cpp:93: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x000000000feda537 6. /build/src/IO/ReadWriteBufferFromHTTP.cpp:277: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x000000001184a4c4 7. /build/src/IO/ReadWriteBufferFromHTTP.cpp:285: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x000000001184a615 8. /build/src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x000000001184ae59 9. /build/src/IO/ReadWriteBufferFromHTTP.cpp:472: void std::__function::__policy_invoker::__call_impl[abi:se190107]>(std::__function::__policy_storage const*) @ 0x000000001184cedd 10. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001184858b 11. /build/src/IO/ReadWriteBufferFromHTTP.cpp:465: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x000000001184bf0b 12. /build/src/IO/ReadBuffer.h:60: DB::ReadBuffer::next() @ 0x000000000a148c7b 13. /build/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) @ 0x0000000011849fb2 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]>&)>&, 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&) @ 0x0000000011841980 15. /build/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) @ 0x000000001621208e 16. /build/src/Storages/StorageReplicatedMergeTree.cpp:5228: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl[abi:se190107] const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000015f9a5fe 17. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000015ed8bfd 18. /build/src/Storages/StorageReplicatedMergeTree.cpp:2514: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x0000000015ec9aab 19. /build/src/Storages/StorageReplicatedMergeTree.cpp:2349: DB::StorageReplicatedMergeTree::executeLogEntry(DB::ReplicatedMergeTreeLogEntry&) @ 0x0000000015eba91b 20. /build/src/Storages/StorageReplicatedMergeTree.cpp:3876: bool std::__function::__policy_invoker&)>::__call_impl[abi:se190107])::$_1, bool (std::shared_ptr&)>>(std::__function::__policy_storage const*, std::shared_ptr&) @ 0x0000000015f9837e 21. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000165d6fc3 22. /build/src/Storages/StorageReplicatedMergeTree.cpp:3872: DB::StorageReplicatedMergeTree::processQueueEntry(std::shared_ptr) @ 0x0000000015efc18a 23. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001624c1b2 24. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000162f9c70 25. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x00000000162fa55a 26. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc6653 27. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000000fccc4c3 28. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc3d92 29. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fcca080 30. ? @ 0x00007fbc6213eac3 31. ? @ 0x00007fbc621d0850 (version 25.3.6.10636.altinitytest (altinity build)) 2025.07.28 11:52:05.254320 [ 3974 ] {} test_13.rmt2 (7f9b740d-015c-470e-8cc6-8ba33be0dc63): auto DB::StorageReplicatedMergeTree::processQueueEntry(ReplicatedMergeTreeQueue::SelectedEntryPtr)::(anonymous class)::operator()(LogEntryPtr &) const: Code: 86. DB::HTTPException: Received error from remote server http://146b4357c08d:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Ftest%2F01165%2Ftest_13%2Frmt%2Freplicas%2F1&part=20250728_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.6.10636.altinitytest (altinity build)) '. (RECEIVED_ERROR_FROM_REMOTE_IO_SERVER), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.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 const&, int&&, String const&, unsigned long&&, String const&) @ 0x000000000feda8d9 4. /build/src/IO/HTTPCommon.cpp:104: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x000000000feda6e2 5. /build/src/IO/HTTPCommon.cpp:93: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x000000000feda537 6. /build/src/IO/ReadWriteBufferFromHTTP.cpp:277: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x000000001184a4c4 7. /build/src/IO/ReadWriteBufferFromHTTP.cpp:285: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x000000001184a615 8. /build/src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x000000001184ae59 9. /build/src/IO/ReadWriteBufferFromHTTP.cpp:472: void std::__function::__policy_invoker::__call_impl[abi:se190107]>(std::__function::__policy_storage const*) @ 0x000000001184cedd 10. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001184858b 11. /build/src/IO/ReadWriteBufferFromHTTP.cpp:465: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x000000001184bf0b 12. /build/src/IO/ReadBuffer.h:60: DB::ReadBuffer::next() @ 0x000000000a148c7b 13. /build/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) @ 0x0000000011849fb2 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]>&)>&, 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&) @ 0x0000000011841980 15. /build/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) @ 0x000000001621208e 16. /build/src/Storages/StorageReplicatedMergeTree.cpp:5228: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl[abi:se190107] const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000015f9a5fe 17. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000015ed8bfd 18. /build/src/Storages/StorageReplicatedMergeTree.cpp:2514: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x0000000015ec9aab 19. /build/src/Storages/StorageReplicatedMergeTree.cpp:2349: DB::StorageReplicatedMergeTree::executeLogEntry(DB::ReplicatedMergeTreeLogEntry&) @ 0x0000000015eba91b 20. /build/src/Storages/StorageReplicatedMergeTree.cpp:3876: bool std::__function::__policy_invoker&)>::__call_impl[abi:se190107])::$_1, bool (std::shared_ptr&)>>(std::__function::__policy_storage const*, std::shared_ptr&) @ 0x0000000015f9837e 21. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000165d6fc3 22. /build/src/Storages/StorageReplicatedMergeTree.cpp:3872: DB::StorageReplicatedMergeTree::processQueueEntry(std::shared_ptr) @ 0x0000000015efc18a 23. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001624c1b2 24. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000162f9c70 25. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x00000000162fa55a 26. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc6653 27. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000000fccc4c3 28. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc3d92 29. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fcca080 30. ? @ 0x00007fbc6213eac3 31. ? @ 0x00007fbc621d0850 (version 25.3.6.10636.altinitytest (altinity build)) 2025.07.28 11:52:05.758524 [ 17210 ] {3010b3af-1059-4341-a5ed-1cd2a55fcec6} executeQuery: Code: 48. DB::Exception: ReplicatedMergeTree (table rdb_test_y1ko7xdm.a (15fbd03e-8826-45a4-834c-92757e8739bb)) does not support transactions. (NOT_IMPLEMENTED) (version 25.3.6.10636.altinitytest (altinity build)) (from [::1]:49482) (comment: 03234_replicated_table_parent_znode_cleanup.sh) (query 2, line 3) (in query: drop table rdb_test_y1ko7xdm.a sync;), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x000000000a06b56b 4. /build/src/Interpreters/IInterpreter.cpp:55: DB::IInterpreter::checkStorageSupportsTransactionsIfNeeded(std::shared_ptr const&, std::shared_ptr, bool) @ 0x00000000148e6f26 5. /build/src/Interpreters/InterpreterDropQuery.cpp:156: DB::InterpreterDropQuery::executeToTableImpl(std::shared_ptr const&, DB::ASTDropQuery&, std::shared_ptr&, StrongTypedef, DB::UUIDTag>&) @ 0x000000001491415d 6. /build/src/Interpreters/InterpreterDropQuery.cpp:118: DB::InterpreterDropQuery::executeToTable(DB::ASTDropQuery&) @ 0x00000000149137b4 7. /build/src/Interpreters/InterpreterDropQuery.cpp:91: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000014912f07 8. /build/src/Interpreters/InterpreterDropQuery.cpp:72: DB::InterpreterDropQuery::execute() @ 0x0000000014912b65 9. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88dc9 10. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 11. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 12. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 13. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 14. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 16. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 17. ? @ 0x00007fbc6213eac3 18. ? @ 0x00007fbc621d0850 2025.07.28 11:52:05.773390 [ 17210 ] {} TCPHandler: Code: 48. DB::Exception: ReplicatedMergeTree (table rdb_test_y1ko7xdm.a (15fbd03e-8826-45a4-834c-92757e8739bb)) does not support transactions. (NOT_IMPLEMENTED), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x000000000a06b56b 4. /build/src/Interpreters/IInterpreter.cpp:55: DB::IInterpreter::checkStorageSupportsTransactionsIfNeeded(std::shared_ptr const&, std::shared_ptr, bool) @ 0x00000000148e6f26 5. /build/src/Interpreters/InterpreterDropQuery.cpp:156: DB::InterpreterDropQuery::executeToTableImpl(std::shared_ptr const&, DB::ASTDropQuery&, std::shared_ptr&, StrongTypedef, DB::UUIDTag>&) @ 0x000000001491415d 6. /build/src/Interpreters/InterpreterDropQuery.cpp:118: DB::InterpreterDropQuery::executeToTable(DB::ASTDropQuery&) @ 0x00000000149137b4 7. /build/src/Interpreters/InterpreterDropQuery.cpp:91: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000014912f07 8. /build/src/Interpreters/InterpreterDropQuery.cpp:72: DB::InterpreterDropQuery::execute() @ 0x0000000014912b65 9. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88dc9 10. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 11. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 12. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 13. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 14. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 16. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 17. ? @ 0x00007fbc6213eac3 18. ? @ 0x00007fbc621d0850 2025.07.28 11:52:05.885156 [ 3961 ] {} test_13.rmt2 (7f9b740d-015c-470e-8cc6-8ba33be0dc63): auto DB::StorageReplicatedMergeTree::processQueueEntry(ReplicatedMergeTreeQueue::SelectedEntryPtr)::(anonymous class)::operator()(LogEntryPtr &) const: Code: 86. DB::HTTPException: Received error from remote server http://146b4357c08d:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Ftest%2F01165%2Ftest_13%2Frmt%2Freplicas%2F1&part=20250728_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.6.10636.altinitytest (altinity build)) '. (RECEIVED_ERROR_FROM_REMOTE_IO_SERVER), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.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 const&, int&&, String const&, unsigned long&&, String const&) @ 0x000000000feda8d9 4. /build/src/IO/HTTPCommon.cpp:104: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x000000000feda6e2 5. /build/src/IO/HTTPCommon.cpp:93: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x000000000feda537 6. /build/src/IO/ReadWriteBufferFromHTTP.cpp:277: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x000000001184a4c4 7. /build/src/IO/ReadWriteBufferFromHTTP.cpp:285: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x000000001184a615 8. /build/src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x000000001184ae59 9. /build/src/IO/ReadWriteBufferFromHTTP.cpp:472: void std::__function::__policy_invoker::__call_impl[abi:se190107]>(std::__function::__policy_storage const*) @ 0x000000001184cedd 10. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001184858b 11. /build/src/IO/ReadWriteBufferFromHTTP.cpp:465: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x000000001184bf0b 12. /build/src/IO/ReadBuffer.h:60: DB::ReadBuffer::next() @ 0x000000000a148c7b 13. /build/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) @ 0x0000000011849fb2 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]>&)>&, 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&) @ 0x0000000011841980 15. /build/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) @ 0x000000001621208e 16. /build/src/Storages/StorageReplicatedMergeTree.cpp:5228: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl[abi:se190107] const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000015f9a5fe 17. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000015ed8bfd 18. /build/src/Storages/StorageReplicatedMergeTree.cpp:2514: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x0000000015ec9aab 19. /build/src/Storages/StorageReplicatedMergeTree.cpp:2349: DB::StorageReplicatedMergeTree::executeLogEntry(DB::ReplicatedMergeTreeLogEntry&) @ 0x0000000015eba91b 20. /build/src/Storages/StorageReplicatedMergeTree.cpp:3876: bool std::__function::__policy_invoker&)>::__call_impl[abi:se190107])::$_1, bool (std::shared_ptr&)>>(std::__function::__policy_storage const*, std::shared_ptr&) @ 0x0000000015f9837e 21. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000165d6fc3 22. /build/src/Storages/StorageReplicatedMergeTree.cpp:3872: DB::StorageReplicatedMergeTree::processQueueEntry(std::shared_ptr) @ 0x0000000015efc18a 23. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001624c1b2 24. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000162f9c70 25. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x00000000162fa55a 26. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc6653 27. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000000fccc4c3 28. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc3d92 29. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fcca080 30. ? @ 0x00007fbc6213eac3 31. ? @ 0x00007fbc621d0850 (version 25.3.6.10636.altinitytest (altinity build)) 2025.07.28 11:52:06.104009 [ 17256 ] {709f0793-a706-4669-8d29-d46ff2aba412} executeQuery: Code: 48. DB::Exception: ReplicatedMergeTree (table rdb_test_y1ko7xdm.a (15fbd03e-8826-45a4-834c-92757e8739bb)) does not support transactions. (NOT_IMPLEMENTED) (version 25.3.6.10636.altinitytest (altinity build)) (from [::1]:49536) (comment: 03234_replicated_table_parent_znode_cleanup.sh) (query 1, line 1) (in query: drop database rdb_test_y1ko7xdm), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x000000000a06b56b 4. /build/src/Interpreters/IInterpreter.cpp:55: DB::IInterpreter::checkStorageSupportsTransactionsIfNeeded(std::shared_ptr const&, std::shared_ptr, bool) @ 0x00000000148e6f26 5. /build/src/Interpreters/InterpreterDropQuery.cpp:156: DB::InterpreterDropQuery::executeToTableImpl(std::shared_ptr const&, DB::ASTDropQuery&, std::shared_ptr&, StrongTypedef, DB::UUIDTag>&) @ 0x000000001491415d 6. /build/src/Interpreters/InterpreterDropQuery.cpp:461: DB::InterpreterDropQuery::executeToDatabaseImpl(DB::ASTDropQuery const&, std::shared_ptr&, std::vector, DB::UUIDTag>, std::allocator, DB::UUIDTag>>>&) @ 0x0000000014917707 7. /build/src/Interpreters/InterpreterDropQuery.cpp:363: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x0000000014913988 8. /build/src/Interpreters/InterpreterDropQuery.cpp:99: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000014913142 9. /build/src/Interpreters/InterpreterDropQuery.cpp:72: DB::InterpreterDropQuery::execute() @ 0x0000000014912b65 10. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88dc9 11. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 12. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 13. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 14. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 15. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 16. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 17. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 18. ? @ 0x00007fbc6213eac3 19. ? @ 0x00007fbc621d0850 2025.07.28 11:52:06.160709 [ 17256 ] {} TCPHandler: Code: 48. DB::Exception: ReplicatedMergeTree (table rdb_test_y1ko7xdm.a (15fbd03e-8826-45a4-834c-92757e8739bb)) does not support transactions. (NOT_IMPLEMENTED), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x000000000a06b56b 4. /build/src/Interpreters/IInterpreter.cpp:55: DB::IInterpreter::checkStorageSupportsTransactionsIfNeeded(std::shared_ptr const&, std::shared_ptr, bool) @ 0x00000000148e6f26 5. /build/src/Interpreters/InterpreterDropQuery.cpp:156: DB::InterpreterDropQuery::executeToTableImpl(std::shared_ptr const&, DB::ASTDropQuery&, std::shared_ptr&, StrongTypedef, DB::UUIDTag>&) @ 0x000000001491415d 6. /build/src/Interpreters/InterpreterDropQuery.cpp:461: DB::InterpreterDropQuery::executeToDatabaseImpl(DB::ASTDropQuery const&, std::shared_ptr&, std::vector, DB::UUIDTag>, std::allocator, DB::UUIDTag>>>&) @ 0x0000000014917707 7. /build/src/Interpreters/InterpreterDropQuery.cpp:363: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x0000000014913988 8. /build/src/Interpreters/InterpreterDropQuery.cpp:99: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000014913142 9. /build/src/Interpreters/InterpreterDropQuery.cpp:72: DB::InterpreterDropQuery::execute() @ 0x0000000014912b65 10. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88dc9 11. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 12. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 13. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 14. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 15. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 16. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 17. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 18. ? @ 0x00007fbc6213eac3 19. ? @ 0x00007fbc621d0850 2025.07.28 11:52:06.398734 [ 3970 ] {} test_13.rmt2 (7f9b740d-015c-470e-8cc6-8ba33be0dc63): auto DB::StorageReplicatedMergeTree::processQueueEntry(ReplicatedMergeTreeQueue::SelectedEntryPtr)::(anonymous class)::operator()(LogEntryPtr &) const: Code: 86. DB::HTTPException: Received error from remote server http://146b4357c08d:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Ftest%2F01165%2Ftest_13%2Frmt%2Freplicas%2F1&part=20250728_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.6.10636.altinitytest (altinity build)) '. (RECEIVED_ERROR_FROM_REMOTE_IO_SERVER), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.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 const&, int&&, String const&, unsigned long&&, String const&) @ 0x000000000feda8d9 4. /build/src/IO/HTTPCommon.cpp:104: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x000000000feda6e2 5. /build/src/IO/HTTPCommon.cpp:93: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x000000000feda537 6. /build/src/IO/ReadWriteBufferFromHTTP.cpp:277: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x000000001184a4c4 7. /build/src/IO/ReadWriteBufferFromHTTP.cpp:285: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x000000001184a615 8. /build/src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x000000001184ae59 9. /build/src/IO/ReadWriteBufferFromHTTP.cpp:472: void std::__function::__policy_invoker::__call_impl[abi:se190107]>(std::__function::__policy_storage const*) @ 0x000000001184cedd 10. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001184858b 11. /build/src/IO/ReadWriteBufferFromHTTP.cpp:465: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x000000001184bf0b 12. /build/src/IO/ReadBuffer.h:60: DB::ReadBuffer::next() @ 0x000000000a148c7b 13. /build/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) @ 0x0000000011849fb2 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]>&)>&, 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&) @ 0x0000000011841980 15. /build/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) @ 0x000000001621208e 16. /build/src/Storages/StorageReplicatedMergeTree.cpp:5228: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl[abi:se190107] const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000015f9a5fe 17. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000015ed8bfd 18. /build/src/Storages/StorageReplicatedMergeTree.cpp:2514: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x0000000015ec9aab 19. /build/src/Storages/StorageReplicatedMergeTree.cpp:2349: DB::StorageReplicatedMergeTree::executeLogEntry(DB::ReplicatedMergeTreeLogEntry&) @ 0x0000000015eba91b 20. /build/src/Storages/StorageReplicatedMergeTree.cpp:3876: bool std::__function::__policy_invoker&)>::__call_impl[abi:se190107])::$_1, bool (std::shared_ptr&)>>(std::__function::__policy_storage const*, std::shared_ptr&) @ 0x0000000015f9837e 21. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000165d6fc3 22. /build/src/Storages/StorageReplicatedMergeTree.cpp:3872: DB::StorageReplicatedMergeTree::processQueueEntry(std::shared_ptr) @ 0x0000000015efc18a 23. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001624c1b2 24. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000162f9c70 25. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x00000000162fa55a 26. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc6653 27. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000000fccc4c3 28. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc3d92 29. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fcca080 30. ? @ 0x00007fbc6213eac3 31. ? @ 0x00007fbc621d0850 (version 25.3.6.10636.altinitytest (altinity build)) 2025.07.28 11:52:06.656456 [ 17255 ] {bae3dd0a-db6c-4ecd-a192-eb2a3c6c6bf3} 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.6.10636.altinitytest (altinity build)) (from [::1]:49494) (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. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&, String&&, String const&) @ 0x000000001639468b 4. /build/src/Storages/MergeTree/MergeTreeData.cpp:3958: DB::MergeTreeData::checkAlterIsPossible(DB::AlterCommands const&, std::shared_ptr) const @ 0x0000000016338047 5. /build/src/Interpreters/InterpreterAlterQuery.cpp:215: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x00000000148deab3 6. /build/src/Interpreters/InterpreterAlterQuery.cpp:77: DB::InterpreterAlterQuery::execute() @ 0x00000000148dcb0d 7. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88dc9 8. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 9. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 10. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 11. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 12. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 13. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 14. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 15. ? @ 0x00007fbc6213eac3 16. ? @ 0x00007fbc621d0850 2025.07.28 11:52:06.663262 [ 17255 ] {} 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. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&, String&&, String const&) @ 0x000000001639468b 4. /build/src/Storages/MergeTree/MergeTreeData.cpp:3958: DB::MergeTreeData::checkAlterIsPossible(DB::AlterCommands const&, std::shared_ptr) const @ 0x0000000016338047 5. /build/src/Interpreters/InterpreterAlterQuery.cpp:215: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x00000000148deab3 6. /build/src/Interpreters/InterpreterAlterQuery.cpp:77: DB::InterpreterAlterQuery::execute() @ 0x00000000148dcb0d 7. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88dc9 8. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 9. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 10. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 11. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 12. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 13. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 14. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 15. ? @ 0x00007fbc6213eac3 16. ? @ 0x00007fbc621d0850 2025.07.28 11:52:06.878901 [ 3969 ] {} test_13.rmt2 (7f9b740d-015c-470e-8cc6-8ba33be0dc63): auto DB::StorageReplicatedMergeTree::processQueueEntry(ReplicatedMergeTreeQueue::SelectedEntryPtr)::(anonymous class)::operator()(LogEntryPtr &) const: Code: 86. DB::HTTPException: Received error from remote server http://146b4357c08d:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Ftest%2F01165%2Ftest_13%2Frmt%2Freplicas%2F1&part=20250728_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.6.10636.altinitytest (altinity build)) '. (RECEIVED_ERROR_FROM_REMOTE_IO_SERVER), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.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 const&, int&&, String const&, unsigned long&&, String const&) @ 0x000000000feda8d9 4. /build/src/IO/HTTPCommon.cpp:104: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x000000000feda6e2 5. /build/src/IO/HTTPCommon.cpp:93: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x000000000feda537 6. /build/src/IO/ReadWriteBufferFromHTTP.cpp:277: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x000000001184a4c4 7. /build/src/IO/ReadWriteBufferFromHTTP.cpp:285: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x000000001184a615 8. /build/src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x000000001184ae59 9. /build/src/IO/ReadWriteBufferFromHTTP.cpp:472: void std::__function::__policy_invoker::__call_impl[abi:se190107]>(std::__function::__policy_storage const*) @ 0x000000001184cedd 10. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001184858b 11. /build/src/IO/ReadWriteBufferFromHTTP.cpp:465: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x000000001184bf0b 12. /build/src/IO/ReadBuffer.h:60: DB::ReadBuffer::next() @ 0x000000000a148c7b 13. /build/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) @ 0x0000000011849fb2 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]>&)>&, 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&) @ 0x0000000011841980 15. /build/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) @ 0x000000001621208e 16. /build/src/Storages/StorageReplicatedMergeTree.cpp:5228: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl[abi:se190107] const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000015f9a5fe 17. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000015ed8bfd 18. /build/src/Storages/StorageReplicatedMergeTree.cpp:2514: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x0000000015ec9aab 19. /build/src/Storages/StorageReplicatedMergeTree.cpp:2349: DB::StorageReplicatedMergeTree::executeLogEntry(DB::ReplicatedMergeTreeLogEntry&) @ 0x0000000015eba91b 20. /build/src/Storages/StorageReplicatedMergeTree.cpp:3876: bool std::__function::__policy_invoker&)>::__call_impl[abi:se190107])::$_1, bool (std::shared_ptr&)>>(std::__function::__policy_storage const*, std::shared_ptr&) @ 0x0000000015f9837e 21. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000165d6fc3 22. /build/src/Storages/StorageReplicatedMergeTree.cpp:3872: DB::StorageReplicatedMergeTree::processQueueEntry(std::shared_ptr) @ 0x0000000015efc18a 23. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001624c1b2 24. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000162f9c70 25. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x00000000162fa55a 26. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc6653 27. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000000fccc4c3 28. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc3d92 29. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fcca080 30. ? @ 0x00007fbc6213eac3 31. ? @ 0x00007fbc621d0850 (version 25.3.6.10636.altinitytest (altinity build)) 2025.07.28 11:52:07.448601 [ 3971 ] {} test_13.rmt2 (7f9b740d-015c-470e-8cc6-8ba33be0dc63): auto DB::StorageReplicatedMergeTree::processQueueEntry(ReplicatedMergeTreeQueue::SelectedEntryPtr)::(anonymous class)::operator()(LogEntryPtr &) const: Code: 86. DB::HTTPException: Received error from remote server http://146b4357c08d:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Ftest%2F01165%2Ftest_13%2Frmt%2Freplicas%2F1&part=20250728_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.6.10636.altinitytest (altinity build)) '. (RECEIVED_ERROR_FROM_REMOTE_IO_SERVER), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.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 const&, int&&, String const&, unsigned long&&, String const&) @ 0x000000000feda8d9 4. /build/src/IO/HTTPCommon.cpp:104: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x000000000feda6e2 5. /build/src/IO/HTTPCommon.cpp:93: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x000000000feda537 6. /build/src/IO/ReadWriteBufferFromHTTP.cpp:277: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x000000001184a4c4 7. /build/src/IO/ReadWriteBufferFromHTTP.cpp:285: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x000000001184a615 8. /build/src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x000000001184ae59 9. /build/src/IO/ReadWriteBufferFromHTTP.cpp:472: void std::__function::__policy_invoker::__call_impl[abi:se190107]>(std::__function::__policy_storage const*) @ 0x000000001184cedd 10. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001184858b 11. /build/src/IO/ReadWriteBufferFromHTTP.cpp:465: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x000000001184bf0b 12. /build/src/IO/ReadBuffer.h:60: DB::ReadBuffer::next() @ 0x000000000a148c7b 13. /build/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) @ 0x0000000011849fb2 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]>&)>&, 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&) @ 0x0000000011841980 15. /build/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) @ 0x000000001621208e 16. /build/src/Storages/StorageReplicatedMergeTree.cpp:5228: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl[abi:se190107] const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000015f9a5fe 17. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000015ed8bfd 18. /build/src/Storages/StorageReplicatedMergeTree.cpp:2514: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x0000000015ec9aab 19. /build/src/Storages/StorageReplicatedMergeTree.cpp:2349: DB::StorageReplicatedMergeTree::executeLogEntry(DB::ReplicatedMergeTreeLogEntry&) @ 0x0000000015eba91b 20. /build/src/Storages/StorageReplicatedMergeTree.cpp:3876: bool std::__function::__policy_invoker&)>::__call_impl[abi:se190107])::$_1, bool (std::shared_ptr&)>>(std::__function::__policy_storage const*, std::shared_ptr&) @ 0x0000000015f9837e 21. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000165d6fc3 22. /build/src/Storages/StorageReplicatedMergeTree.cpp:3872: DB::StorageReplicatedMergeTree::processQueueEntry(std::shared_ptr) @ 0x0000000015efc18a 23. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001624c1b2 24. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000162f9c70 25. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x00000000162fa55a 26. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc6653 27. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000000fccc4c3 28. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc3d92 29. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fcca080 30. ? @ 0x00007fbc6213eac3 31. ? @ 0x00007fbc621d0850 (version 25.3.6.10636.altinitytest (altinity build)) 2025.07.28 11:52:08.116335 [ 3283 ] {3347161f-635f-4afa-bf8b-3ce8314ca716} executeQuery: Code: 117. DB::Exception: Cannot parse text value of type Variant(Date) here: 42: In scope SELECT CAST('42', 'Variant(Date)') AS v, variantType(v). (INCORRECT_DATA) (version 25.3.6.10636.altinitytest (altinity build)) (from [::1]:49578) (comment: 03032_string_to_variant_cast.sql) (query 7, line 7) (in query: select CAST('42', 'Variant(Date)') as v, variantType(v);), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&) @ 0x000000000fe60e6b 4. /build/src/DataTypes/Serializations/SerializationVariant.cpp:1060: DB::SerializationVariant::deserializeWholeText(DB::IColumn&, DB::ReadBuffer&, DB::FormatSettings const&) const @ 0x0000000013d35eb1 5. /build/src/Functions/FunctionsConversion.h:1922: 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&) @ 0x0000000012de920b 6. /build/src/Functions/FunctionsConversion.h:1894: DB::detail::ConvertImplGenericFromString::execute(std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long, std::shared_ptr const&) @ 0x0000000012de7d2d 7. /build/src/Functions/FunctionsConversion.h:5145: DB::detail::FunctionCast::createStringToVariantWrapper() 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 @ 0x0000000012de9978 8. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: COW::immutable_ptr std::__function::__policy_invoker::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)>::__call_impl[abi:se190107]>&, 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) @ 0x0000000012de9749 9. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000012ddcb1b 10. /build/src/Functions/IFunction.h:57: DB::IExecutableFunction::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000a08134a 11. /build/src/Functions/IFunction.cpp:351: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d93b02 12. /build/src/Functions/IFunction.cpp:177: DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d93698 13. /build/src/Functions/IFunction.cpp:343: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d93aad 14. /build/src/Functions/IFunction.cpp:424: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d94e1b 15. /build/src/Functions/IFunction.cpp:498: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d95c72 16. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3567: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000014034494 17. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3838: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000014019a9e 18. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3980: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000014018e31 19. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:4304: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000014042fa7 20. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5605: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000014013749 21. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000140127f9 22. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000014011fce 23. /build/src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000001406ce8a 24. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000014973b42 25. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000001497268d 26. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000014974d24 27. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001492924b 28. /build/src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88641 29. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 30. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 31. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 2025.07.28 11:52:08.133187 [ 3283 ] {} TCPHandler: Code: 117. DB::Exception: Cannot parse text value of type Variant(Date) here: 42: In scope SELECT CAST('42', 'Variant(Date)') AS v, variantType(v). (INCORRECT_DATA), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&) @ 0x000000000fe60e6b 4. /build/src/DataTypes/Serializations/SerializationVariant.cpp:1060: DB::SerializationVariant::deserializeWholeText(DB::IColumn&, DB::ReadBuffer&, DB::FormatSettings const&) const @ 0x0000000013d35eb1 5. /build/src/Functions/FunctionsConversion.h:1922: 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&) @ 0x0000000012de920b 6. /build/src/Functions/FunctionsConversion.h:1894: DB::detail::ConvertImplGenericFromString::execute(std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long, std::shared_ptr const&) @ 0x0000000012de7d2d 7. /build/src/Functions/FunctionsConversion.h:5145: DB::detail::FunctionCast::createStringToVariantWrapper() 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 @ 0x0000000012de9978 8. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: COW::immutable_ptr std::__function::__policy_invoker::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)>::__call_impl[abi:se190107]>&, 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) @ 0x0000000012de9749 9. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000012ddcb1b 10. /build/src/Functions/IFunction.h:57: DB::IExecutableFunction::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000a08134a 11. /build/src/Functions/IFunction.cpp:351: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d93b02 12. /build/src/Functions/IFunction.cpp:177: DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d93698 13. /build/src/Functions/IFunction.cpp:343: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d93aad 14. /build/src/Functions/IFunction.cpp:424: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d94e1b 15. /build/src/Functions/IFunction.cpp:498: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d95c72 16. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3567: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000014034494 17. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3838: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000014019a9e 18. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3980: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000014018e31 19. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:4304: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000014042fa7 20. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5605: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000014013749 21. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000140127f9 22. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000014011fce 23. /build/src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000001406ce8a 24. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000014973b42 25. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000001497268d 26. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000014974d24 27. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001492924b 28. /build/src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88641 29. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 30. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 31. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 2025.07.28 11:52:08.456151 [ 3967 ] {} test_13.rmt2 (7f9b740d-015c-470e-8cc6-8ba33be0dc63): auto DB::StorageReplicatedMergeTree::processQueueEntry(ReplicatedMergeTreeQueue::SelectedEntryPtr)::(anonymous class)::operator()(LogEntryPtr &) const: Code: 86. DB::HTTPException: Received error from remote server http://146b4357c08d:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Ftest%2F01165%2Ftest_13%2Frmt%2Freplicas%2F1&part=20250728_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.6.10636.altinitytest (altinity build)) '. (RECEIVED_ERROR_FROM_REMOTE_IO_SERVER), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.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 const&, int&&, String const&, unsigned long&&, String const&) @ 0x000000000feda8d9 4. /build/src/IO/HTTPCommon.cpp:104: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x000000000feda6e2 5. /build/src/IO/HTTPCommon.cpp:93: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x000000000feda537 6. /build/src/IO/ReadWriteBufferFromHTTP.cpp:277: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x000000001184a4c4 7. /build/src/IO/ReadWriteBufferFromHTTP.cpp:285: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x000000001184a615 8. /build/src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x000000001184ae59 9. /build/src/IO/ReadWriteBufferFromHTTP.cpp:472: void std::__function::__policy_invoker::__call_impl[abi:se190107]>(std::__function::__policy_storage const*) @ 0x000000001184cedd 10. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001184858b 11. /build/src/IO/ReadWriteBufferFromHTTP.cpp:465: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x000000001184bf0b 12. /build/src/IO/ReadBuffer.h:60: DB::ReadBuffer::next() @ 0x000000000a148c7b 13. /build/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) @ 0x0000000011849fb2 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]>&)>&, 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&) @ 0x0000000011841980 15. /build/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) @ 0x000000001621208e 16. /build/src/Storages/StorageReplicatedMergeTree.cpp:5228: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl[abi:se190107] const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000015f9a5fe 17. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000015ed8bfd 18. /build/src/Storages/StorageReplicatedMergeTree.cpp:2514: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x0000000015ec9aab 19. /build/src/Storages/StorageReplicatedMergeTree.cpp:2349: DB::StorageReplicatedMergeTree::executeLogEntry(DB::ReplicatedMergeTreeLogEntry&) @ 0x0000000015eba91b 20. /build/src/Storages/StorageReplicatedMergeTree.cpp:3876: bool std::__function::__policy_invoker&)>::__call_impl[abi:se190107])::$_1, bool (std::shared_ptr&)>>(std::__function::__policy_storage const*, std::shared_ptr&) @ 0x0000000015f9837e 21. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000165d6fc3 22. /build/src/Storages/StorageReplicatedMergeTree.cpp:3872: DB::StorageReplicatedMergeTree::processQueueEntry(std::shared_ptr) @ 0x0000000015efc18a 23. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001624c1b2 24. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000162f9c70 25. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x00000000162fa55a 26. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc6653 27. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000000fccc4c3 28. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc3d92 29. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fcca080 30. ? @ 0x00007fbc6213eac3 31. ? @ 0x00007fbc621d0850 (version 25.3.6.10636.altinitytest (altinity build)) 2025.07.28 11:52:08.845108 [ 17255 ] {9ad2cfe2-d9ef-4a31-8df8-be3b45ab5a8a} 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.6.10636.altinitytest (altinity build)) (from [::1]:49494) (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. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&, String&&, String const&) @ 0x000000001639468b 4. /build/src/Storages/MergeTree/MergeTreeData.cpp:3958: DB::MergeTreeData::checkAlterIsPossible(DB::AlterCommands const&, std::shared_ptr) const @ 0x0000000016338047 5. /build/src/Interpreters/InterpreterAlterQuery.cpp:215: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x00000000148deab3 6. /build/src/Interpreters/InterpreterAlterQuery.cpp:77: DB::InterpreterAlterQuery::execute() @ 0x00000000148dcb0d 7. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88dc9 8. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 9. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 10. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 11. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 12. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 13. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 14. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 15. ? @ 0x00007fbc6213eac3 16. ? @ 0x00007fbc621d0850 2025.07.28 11:52:08.853287 [ 17255 ] {} 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. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&, String&&, String const&) @ 0x000000001639468b 4. /build/src/Storages/MergeTree/MergeTreeData.cpp:3958: DB::MergeTreeData::checkAlterIsPossible(DB::AlterCommands const&, std::shared_ptr) const @ 0x0000000016338047 5. /build/src/Interpreters/InterpreterAlterQuery.cpp:215: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x00000000148deab3 6. /build/src/Interpreters/InterpreterAlterQuery.cpp:77: DB::InterpreterAlterQuery::execute() @ 0x00000000148dcb0d 7. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88dc9 8. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 9. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 10. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 11. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 12. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 13. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 14. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 15. ? @ 0x00007fbc6213eac3 16. ? @ 0x00007fbc621d0850 2025.07.28 11:52:09.049762 [ 17255 ] {e9631145-7178-4779-bbb6-46b81aef759e} executeQuery: Code: 57. DB::Exception: Table test_1.`02500_nested` already exists. (TABLE_ALREADY_EXISTS) (version 25.3.6.10636.altinitytest (altinity build)) (from [::1]:49494) (comment: 02500_prevent_drop_nested_if_empty_part.sql) (query 18, line 24) (in query: CREATE TABLE `02500_nested` (`nes` Array(Tuple(a Int32, b Int32)), `z` Int32) ENGINE = MergeTree ORDER BY tuple() SETTINGS index_granularity = 48099, min_bytes_for_wide_part = 59022822, ratio_of_defaults_for_sparse_serialization = 0.6752611994743347, replace_long_file_name_to_hash = false, max_file_name_length = 128, min_bytes_for_full_part_storage = 505386154, compact_parts_max_bytes_to_buffer = 433335287, compact_parts_max_granules_to_buffer = 184, compact_parts_merge_max_bytes_to_prefetch_part = 28400954, merge_max_block_size = 11641, old_parts_lifetime = 10., prefer_fetch_merged_part_size_threshold = 3672859206, vertical_merge_algorithm_min_rows_to_activate = 1000000, vertical_merge_algorithm_min_columns_to_activate = 100, min_merge_bytes_to_use_direct_io = 9024224813, index_granularity_bytes = 12841250, use_const_adaptive_granularity = true, enable_index_granularity_compression = false, concurrent_part_removal_threshold = 40, 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 = 22594, primary_key_compress_block_size = 79585, 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. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000a06a8eb 4. /build/src/Interpreters/InterpreterCreateQuery.cpp:1824: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x0000000014901d53 5. /build/src/Interpreters/InterpreterCreateQuery.cpp:1743: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000148f9aa9 6. /build/src/Interpreters/InterpreterCreateQuery.cpp:2352: DB::InterpreterCreateQuery::execute() @ 0x0000000014905a41 7. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88dc9 8. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 9. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 10. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 11. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 12. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 13. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 14. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 15. ? @ 0x00007fbc6213eac3 16. ? @ 0x00007fbc621d0850 2025.07.28 11:52:09.061324 [ 17255 ] {} TCPHandler: Code: 57. DB::Exception: Table test_1.`02500_nested` already exists. (TABLE_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000a06a8eb 4. /build/src/Interpreters/InterpreterCreateQuery.cpp:1824: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x0000000014901d53 5. /build/src/Interpreters/InterpreterCreateQuery.cpp:1743: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000148f9aa9 6. /build/src/Interpreters/InterpreterCreateQuery.cpp:2352: DB::InterpreterCreateQuery::execute() @ 0x0000000014905a41 7. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88dc9 8. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 9. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 10. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 11. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 12. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 13. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 14. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 15. ? @ 0x00007fbc6213eac3 16. ? @ 0x00007fbc621d0850 2025.07.28 11:52:09.457253 [ 3972 ] {} test_13.rmt2 (7f9b740d-015c-470e-8cc6-8ba33be0dc63): auto DB::StorageReplicatedMergeTree::processQueueEntry(ReplicatedMergeTreeQueue::SelectedEntryPtr)::(anonymous class)::operator()(LogEntryPtr &) const: Code: 86. DB::HTTPException: Received error from remote server http://146b4357c08d:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Ftest%2F01165%2Ftest_13%2Frmt%2Freplicas%2F1&part=20250728_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.6.10636.altinitytest (altinity build)) '. (RECEIVED_ERROR_FROM_REMOTE_IO_SERVER), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.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 const&, int&&, String const&, unsigned long&&, String const&) @ 0x000000000feda8d9 4. /build/src/IO/HTTPCommon.cpp:104: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x000000000feda6e2 5. /build/src/IO/HTTPCommon.cpp:93: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x000000000feda537 6. /build/src/IO/ReadWriteBufferFromHTTP.cpp:277: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x000000001184a4c4 7. /build/src/IO/ReadWriteBufferFromHTTP.cpp:285: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x000000001184a615 8. /build/src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x000000001184ae59 9. /build/src/IO/ReadWriteBufferFromHTTP.cpp:472: void std::__function::__policy_invoker::__call_impl[abi:se190107]>(std::__function::__policy_storage const*) @ 0x000000001184cedd 10. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001184858b 11. /build/src/IO/ReadWriteBufferFromHTTP.cpp:465: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x000000001184bf0b 12. /build/src/IO/ReadBuffer.h:60: DB::ReadBuffer::next() @ 0x000000000a148c7b 13. /build/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) @ 0x0000000011849fb2 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]>&)>&, 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&) @ 0x0000000011841980 15. /build/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) @ 0x000000001621208e 16. /build/src/Storages/StorageReplicatedMergeTree.cpp:5228: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl[abi:se190107] const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000015f9a5fe 17. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000015ed8bfd 18. /build/src/Storages/StorageReplicatedMergeTree.cpp:2514: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x0000000015ec9aab 19. /build/src/Storages/StorageReplicatedMergeTree.cpp:2349: DB::StorageReplicatedMergeTree::executeLogEntry(DB::ReplicatedMergeTreeLogEntry&) @ 0x0000000015eba91b 20. /build/src/Storages/StorageReplicatedMergeTree.cpp:3876: bool std::__function::__policy_invoker&)>::__call_impl[abi:se190107])::$_1, bool (std::shared_ptr&)>>(std::__function::__policy_storage const*, std::shared_ptr&) @ 0x0000000015f9837e 21. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000165d6fc3 22. /build/src/Storages/StorageReplicatedMergeTree.cpp:3872: DB::StorageReplicatedMergeTree::processQueueEntry(std::shared_ptr) @ 0x0000000015efc18a 23. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001624c1b2 24. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000162f9c70 25. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x00000000162fa55a 26. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc6653 27. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000000fccc4c3 28. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc3d92 29. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fcca080 30. ? @ 0x00007fbc6213eac3 31. ? @ 0x00007fbc621d0850 (version 25.3.6.10636.altinitytest (altinity build)) 2025.07.28 11:52:09.874089 [ 17251 ] {6221c765-afb8-40aa-a866-a0c68182a40c} executeQuery: Code: 153. DB::Exception: Division by zero: In scope SELECT intDiv(-1, 0). (ILLEGAL_DIVISION) (version 25.3.6.10636.altinitytest (altinity build)) (from [::1]:49630) (comment: 00977_int_div.sql) (query 16, line 31) (in query: SELECT -1 DIV 0;), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000000a074fcb 4. /build/src/Functions/DivisionUtils.h:26: _ZN2DB25throwIfDivisionLeadsToFPEIDB8_S1_EEvT_T0_ @ 0x000000000ba48c94 5. /build/src/Functions/DivisionUtils.h:48: COW::immutable_ptr> DB::FunctionBinaryArithmetic::executeNumeric, DB::DataTypeNumber>(std::vector> const&, DB::DataTypeNumber<_BitInt(8)> const&, DB::DataTypeNumber const&, DB::PODArray, 63ul, 64ul> const*) const @ 0x000000000c503fca 6. /build/src/Functions/FunctionBinaryArithmetic.h:2508: 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&&) @ 0x000000000c502db0 7. /build/src/Functions/FunctionBinaryArithmetic.h:846: 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&&) @ 0x000000000c4bc423 8. /build/src/Functions/FunctionBinaryArithmetic.h:844: DB::FunctionBinaryArithmetic::executeImpl2(std::vector> const&, std::shared_ptr const&, unsigned long, DB::PODArray, 63ul, 64ul> const*) const @ 0x000000000c4b8625 9. /build/src/Functions/FunctionBinaryArithmetic.h:2410: DB::FunctionBinaryArithmetic::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000c4b6bac 10. /build/src/Functions/FunctionBinaryArithmetic.h:2645: DB::FunctionBinaryArithmeticWithConstants::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000c4b5a34 11. /build/src/Functions/IFunction.h:437: DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000a069f2a 12. /build/src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000012d9965a 13. /build/src/Functions/IFunction.cpp:351: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d93b02 14. /build/src/Functions/IFunction.cpp:420: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d95059 15. /build/src/Functions/IFunction.cpp:498: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d95c72 16. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3567: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000014034494 17. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3838: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000014019a9e 18. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3980: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000014018e31 19. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:4304: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000014042fa7 20. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5605: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000014013749 21. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000140127f9 22. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000014011fce 23. /build/src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000001406ce8a 24. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000014973b42 25. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000001497268d 26. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000014974d24 27. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001492924b 28. /build/src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88641 29. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 30. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 31. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 2025.07.28 11:52:09.899123 [ 17251 ] {} TCPHandler: Code: 153. DB::Exception: Division by zero: In scope SELECT intDiv(-1, 0). (ILLEGAL_DIVISION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000000a074fcb 4. /build/src/Functions/DivisionUtils.h:26: _ZN2DB25throwIfDivisionLeadsToFPEIDB8_S1_EEvT_T0_ @ 0x000000000ba48c94 5. /build/src/Functions/DivisionUtils.h:48: COW::immutable_ptr> DB::FunctionBinaryArithmetic::executeNumeric, DB::DataTypeNumber>(std::vector> const&, DB::DataTypeNumber<_BitInt(8)> const&, DB::DataTypeNumber const&, DB::PODArray, 63ul, 64ul> const*) const @ 0x000000000c503fca 6. /build/src/Functions/FunctionBinaryArithmetic.h:2508: 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&&) @ 0x000000000c502db0 7. /build/src/Functions/FunctionBinaryArithmetic.h:846: 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&&) @ 0x000000000c4bc423 8. /build/src/Functions/FunctionBinaryArithmetic.h:844: DB::FunctionBinaryArithmetic::executeImpl2(std::vector> const&, std::shared_ptr const&, unsigned long, DB::PODArray, 63ul, 64ul> const*) const @ 0x000000000c4b8625 9. /build/src/Functions/FunctionBinaryArithmetic.h:2410: DB::FunctionBinaryArithmetic::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000c4b6bac 10. /build/src/Functions/FunctionBinaryArithmetic.h:2645: DB::FunctionBinaryArithmeticWithConstants::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000c4b5a34 11. /build/src/Functions/IFunction.h:437: DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000a069f2a 12. /build/src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000012d9965a 13. /build/src/Functions/IFunction.cpp:351: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d93b02 14. /build/src/Functions/IFunction.cpp:420: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d95059 15. /build/src/Functions/IFunction.cpp:498: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d95c72 16. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3567: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000014034494 17. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3838: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000014019a9e 18. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3980: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000014018e31 19. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:4304: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000014042fa7 20. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5605: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000014013749 21. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000140127f9 22. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000014011fce 23. /build/src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000001406ce8a 24. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000014973b42 25. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000001497268d 26. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000014974d24 27. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001492924b 28. /build/src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88641 29. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 30. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 31. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 2025.07.28 11:52:10.399727 [ 3970 ] {} test_13.rmt2 (7f9b740d-015c-470e-8cc6-8ba33be0dc63): auto DB::StorageReplicatedMergeTree::processQueueEntry(ReplicatedMergeTreeQueue::SelectedEntryPtr)::(anonymous class)::operator()(LogEntryPtr &) const: Code: 86. DB::HTTPException: Received error from remote server http://146b4357c08d:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Ftest%2F01165%2Ftest_13%2Frmt%2Freplicas%2F1&part=20250728_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.6.10636.altinitytest (altinity build)) '. (RECEIVED_ERROR_FROM_REMOTE_IO_SERVER), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.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 const&, int&&, String const&, unsigned long&&, String const&) @ 0x000000000feda8d9 4. /build/src/IO/HTTPCommon.cpp:104: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x000000000feda6e2 5. /build/src/IO/HTTPCommon.cpp:93: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x000000000feda537 6. /build/src/IO/ReadWriteBufferFromHTTP.cpp:277: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x000000001184a4c4 7. /build/src/IO/ReadWriteBufferFromHTTP.cpp:285: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x000000001184a615 8. /build/src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x000000001184ae59 9. /build/src/IO/ReadWriteBufferFromHTTP.cpp:472: void std::__function::__policy_invoker::__call_impl[abi:se190107]>(std::__function::__policy_storage const*) @ 0x000000001184cedd 10. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001184858b 11. /build/src/IO/ReadWriteBufferFromHTTP.cpp:465: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x000000001184bf0b 12. /build/src/IO/ReadBuffer.h:60: DB::ReadBuffer::next() @ 0x000000000a148c7b 13. /build/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) @ 0x0000000011849fb2 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]>&)>&, 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&) @ 0x0000000011841980 15. /build/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) @ 0x000000001621208e 16. /build/src/Storages/StorageReplicatedMergeTree.cpp:5228: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl[abi:se190107] const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000015f9a5fe 17. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000015ed8bfd 18. /build/src/Storages/StorageReplicatedMergeTree.cpp:2514: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x0000000015ec9aab 19. /build/src/Storages/StorageReplicatedMergeTree.cpp:2349: DB::StorageReplicatedMergeTree::executeLogEntry(DB::ReplicatedMergeTreeLogEntry&) @ 0x0000000015eba91b 20. /build/src/Storages/StorageReplicatedMergeTree.cpp:3876: bool std::__function::__policy_invoker&)>::__call_impl[abi:se190107])::$_1, bool (std::shared_ptr&)>>(std::__function::__policy_storage const*, std::shared_ptr&) @ 0x0000000015f9837e 21. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000165d6fc3 22. /build/src/Storages/StorageReplicatedMergeTree.cpp:3872: DB::StorageReplicatedMergeTree::processQueueEntry(std::shared_ptr) @ 0x0000000015efc18a 23. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001624c1b2 24. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000162f9c70 25. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x00000000162fa55a 26. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc6653 27. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000000fccc4c3 28. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc3d92 29. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fcca080 30. ? @ 0x00007fbc6213eac3 31. ? @ 0x00007fbc621d0850 (version 25.3.6.10636.altinitytest (altinity build)) 2025.07.28 11:52:10.925747 [ 3283 ] {20fe95e7-d546-4772-9a78-91b95e54bfae} executeQuery: Code: 80. DB::Exception: There are no columns in sampling expression. (INCORRECT_QUERY) (version 25.3.6.10636.altinitytest (altinity build)) (from [::1]:49866) (comment: 02096_sample_by_tuple.sql) (query 2, line 3) (in query: CREATE TABLE t (`n` UInt8) ENGINE = MergeTree ORDER BY n SAMPLE BY tuple() SETTINGS index_granularity = 10691, min_bytes_for_wide_part = 688202026, 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 = 536870912, compact_parts_max_bytes_to_buffer = 203142254, compact_parts_max_granules_to_buffer = 1, compact_parts_merge_max_bytes_to_prefetch_part = 16764971, merge_max_block_size = 13279, old_parts_lifetime = 323., prefer_fetch_merged_part_size_threshold = 1, 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 = 18721891, use_const_adaptive_granularity = true, enable_index_granularity_compression = true, concurrent_part_removal_threshold = 72, allow_vertical_merges_from_compact_to_wide_parts = true, enable_block_number_column = false, enable_block_offset_column = true, cache_populated_by_fetch = true, marks_compress_block_size = 13000, primary_key_compress_block_size = 90764, 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. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000000a074fcb 4. /build/src/Storages/MergeTree/MergeTreeData.cpp:316: DB::checkSampleExpression(DB::StorageInMemoryMetadata const&, bool, bool) @ 0x0000000016303ae6 5. /build/src/Storages/MergeTree/MergeTreeData.cpp:523: 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) @ 0x0000000016301561 6. /build/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>) @ 0x0000000016632995 7. /build/contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: std::shared_ptr std::allocate_shared[abi:se190107], 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>&&) @ 0x00000000166326f0 8. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:851: DB::create(DB::StorageFactory::Arguments const&) @ 0x000000001662f01d 9. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000015d81ea2 10. /build/src/Interpreters/InterpreterCreateQuery.cpp:1945: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x00000000149009bb 11. /build/src/Interpreters/InterpreterCreateQuery.cpp:1743: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000148f9aa9 12. /build/src/Interpreters/InterpreterCreateQuery.cpp:2352: DB::InterpreterCreateQuery::execute() @ 0x0000000014905a41 13. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88dc9 14. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 15. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 16. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 17. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 18. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 19. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 20. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 21. ? @ 0x00007fbc6213eac3 22. ? @ 0x00007fbc621d0850 2025.07.28 11:52:10.939691 [ 3283 ] {} TCPHandler: Code: 80. DB::Exception: There are no columns in sampling expression. (INCORRECT_QUERY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000000a074fcb 4. /build/src/Storages/MergeTree/MergeTreeData.cpp:316: DB::checkSampleExpression(DB::StorageInMemoryMetadata const&, bool, bool) @ 0x0000000016303ae6 5. /build/src/Storages/MergeTree/MergeTreeData.cpp:523: 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) @ 0x0000000016301561 6. /build/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>) @ 0x0000000016632995 7. /build/contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: std::shared_ptr std::allocate_shared[abi:se190107], 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>&&) @ 0x00000000166326f0 8. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:851: DB::create(DB::StorageFactory::Arguments const&) @ 0x000000001662f01d 9. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000015d81ea2 10. /build/src/Interpreters/InterpreterCreateQuery.cpp:1945: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x00000000149009bb 11. /build/src/Interpreters/InterpreterCreateQuery.cpp:1743: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000148f9aa9 12. /build/src/Interpreters/InterpreterCreateQuery.cpp:2352: DB::InterpreterCreateQuery::execute() @ 0x0000000014905a41 13. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88dc9 14. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 15. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 16. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 17. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 18. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 19. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 20. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 21. ? @ 0x00007fbc6213eac3 22. ? @ 0x00007fbc621d0850 2025.07.28 11:52:11.186490 [ 3968 ] {} test_13.rmt2 (7f9b740d-015c-470e-8cc6-8ba33be0dc63): auto DB::StorageReplicatedMergeTree::processQueueEntry(ReplicatedMergeTreeQueue::SelectedEntryPtr)::(anonymous class)::operator()(LogEntryPtr &) const: Code: 86. DB::HTTPException: Received error from remote server http://146b4357c08d:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Ftest%2F01165%2Ftest_13%2Frmt%2Freplicas%2F1&part=20250728_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.6.10636.altinitytest (altinity build)) '. (RECEIVED_ERROR_FROM_REMOTE_IO_SERVER), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.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 const&, int&&, String const&, unsigned long&&, String const&) @ 0x000000000feda8d9 4. /build/src/IO/HTTPCommon.cpp:104: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x000000000feda6e2 5. /build/src/IO/HTTPCommon.cpp:93: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x000000000feda537 6. /build/src/IO/ReadWriteBufferFromHTTP.cpp:277: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x000000001184a4c4 7. /build/src/IO/ReadWriteBufferFromHTTP.cpp:285: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x000000001184a615 8. /build/src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x000000001184ae59 9. /build/src/IO/ReadWriteBufferFromHTTP.cpp:472: void std::__function::__policy_invoker::__call_impl[abi:se190107]>(std::__function::__policy_storage const*) @ 0x000000001184cedd 10. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001184858b 11. /build/src/IO/ReadWriteBufferFromHTTP.cpp:465: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x000000001184bf0b 12. /build/src/IO/ReadBuffer.h:60: DB::ReadBuffer::next() @ 0x000000000a148c7b 13. /build/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) @ 0x0000000011849fb2 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]>&)>&, 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&) @ 0x0000000011841980 15. /build/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) @ 0x000000001621208e 16. /build/src/Storages/StorageReplicatedMergeTree.cpp:5228: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl[abi:se190107] const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000015f9a5fe 17. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000015ed8bfd 18. /build/src/Storages/StorageReplicatedMergeTree.cpp:2514: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x0000000015ec9aab 19. /build/src/Storages/StorageReplicatedMergeTree.cpp:2349: DB::StorageReplicatedMergeTree::executeLogEntry(DB::ReplicatedMergeTreeLogEntry&) @ 0x0000000015eba91b 20. /build/src/Storages/StorageReplicatedMergeTree.cpp:3876: bool std::__function::__policy_invoker&)>::__call_impl[abi:se190107])::$_1, bool (std::shared_ptr&)>>(std::__function::__policy_storage const*, std::shared_ptr&) @ 0x0000000015f9837e 21. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000165d6fc3 22. /build/src/Storages/StorageReplicatedMergeTree.cpp:3872: DB::StorageReplicatedMergeTree::processQueueEntry(std::shared_ptr) @ 0x0000000015efc18a 23. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001624c1b2 24. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000162f9c70 25. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x00000000162fa55a 26. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc6653 27. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000000fccc4c3 28. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc3d92 29. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fcca080 30. ? @ 0x00007fbc6213eac3 31. ? @ 0x00007fbc621d0850 (version 25.3.6.10636.altinitytest (altinity build)) 2025.07.28 11:52:11.327950 [ 3283 ] {2fcc727a-2350-420d-8387-47e3ba09cae7} executeQuery: Code: 80. DB::Exception: There are no columns in sampling expression. (INCORRECT_QUERY) (version 25.3.6.10636.altinitytest (altinity build)) (from [::1]:49866) (comment: 02096_sample_by_tuple.sql) (query 4, line 7) (in query: ALTER TABLE t MODIFY SAMPLE BY tuple();), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000000a074fcb 4. /build/src/Storages/MergeTree/MergeTreeData.cpp:316: DB::checkSampleExpression(DB::StorageInMemoryMetadata const&, bool, bool) @ 0x0000000016303ae6 5. /build/src/Storages/MergeTree/MergeTreeData.cpp:3713: DB::MergeTreeData::checkAlterIsPossible(DB::AlterCommands const&, std::shared_ptr) const @ 0x0000000016336563 6. /build/src/Interpreters/InterpreterAlterQuery.cpp:215: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x00000000148deab3 7. /build/src/Interpreters/InterpreterAlterQuery.cpp:77: DB::InterpreterAlterQuery::execute() @ 0x00000000148dcb0d 8. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88dc9 9. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 10. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 11. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 12. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 13. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 14. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 15. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 16. ? @ 0x00007fbc6213eac3 17. ? @ 0x00007fbc621d0850 2025.07.28 11:52:11.349033 [ 3283 ] {} TCPHandler: Code: 80. DB::Exception: There are no columns in sampling expression. (INCORRECT_QUERY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000000a074fcb 4. /build/src/Storages/MergeTree/MergeTreeData.cpp:316: DB::checkSampleExpression(DB::StorageInMemoryMetadata const&, bool, bool) @ 0x0000000016303ae6 5. /build/src/Storages/MergeTree/MergeTreeData.cpp:3713: DB::MergeTreeData::checkAlterIsPossible(DB::AlterCommands const&, std::shared_ptr) const @ 0x0000000016336563 6. /build/src/Interpreters/InterpreterAlterQuery.cpp:215: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x00000000148deab3 7. /build/src/Interpreters/InterpreterAlterQuery.cpp:77: DB::InterpreterAlterQuery::execute() @ 0x00000000148dcb0d 8. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88dc9 9. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 10. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 11. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 12. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 13. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 14. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 15. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 16. ? @ 0x00007fbc6213eac3 17. ? @ 0x00007fbc621d0850 2025.07.28 11:52:11.406107 [ 3960 ] {} test_13.rmt2 (7f9b740d-015c-470e-8cc6-8ba33be0dc63): auto DB::StorageReplicatedMergeTree::processQueueEntry(ReplicatedMergeTreeQueue::SelectedEntryPtr)::(anonymous class)::operator()(LogEntryPtr &) const: Code: 86. DB::HTTPException: Received error from remote server http://146b4357c08d:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Ftest%2F01165%2Ftest_13%2Frmt%2Freplicas%2F1&part=20250728_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.6.10636.altinitytest (altinity build)) '. (RECEIVED_ERROR_FROM_REMOTE_IO_SERVER), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.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 const&, int&&, String const&, unsigned long&&, String const&) @ 0x000000000feda8d9 4. /build/src/IO/HTTPCommon.cpp:104: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x000000000feda6e2 5. /build/src/IO/HTTPCommon.cpp:93: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x000000000feda537 6. /build/src/IO/ReadWriteBufferFromHTTP.cpp:277: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x000000001184a4c4 7. /build/src/IO/ReadWriteBufferFromHTTP.cpp:285: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x000000001184a615 8. /build/src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x000000001184ae59 9. /build/src/IO/ReadWriteBufferFromHTTP.cpp:472: void std::__function::__policy_invoker::__call_impl[abi:se190107]>(std::__function::__policy_storage const*) @ 0x000000001184cedd 10. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001184858b 11. /build/src/IO/ReadWriteBufferFromHTTP.cpp:465: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x000000001184bf0b 12. /build/src/IO/ReadBuffer.h:60: DB::ReadBuffer::next() @ 0x000000000a148c7b 13. /build/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) @ 0x0000000011849fb2 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]>&)>&, 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&) @ 0x0000000011841980 15. /build/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) @ 0x000000001621208e 16. /build/src/Storages/StorageReplicatedMergeTree.cpp:5228: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl[abi:se190107] const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000015f9a5fe 17. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000015ed8bfd 18. /build/src/Storages/StorageReplicatedMergeTree.cpp:2514: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x0000000015ec9aab 19. /build/src/Storages/StorageReplicatedMergeTree.cpp:2349: DB::StorageReplicatedMergeTree::executeLogEntry(DB::ReplicatedMergeTreeLogEntry&) @ 0x0000000015eba91b 20. /build/src/Storages/StorageReplicatedMergeTree.cpp:3876: bool std::__function::__policy_invoker&)>::__call_impl[abi:se190107])::$_1, bool (std::shared_ptr&)>>(std::__function::__policy_storage const*, std::shared_ptr&) @ 0x0000000015f9837e 21. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000165d6fc3 22. /build/src/Storages/StorageReplicatedMergeTree.cpp:3872: DB::StorageReplicatedMergeTree::processQueueEntry(std::shared_ptr) @ 0x0000000015efc18a 23. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001624c1b2 24. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000162f9c70 25. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x00000000162fa55a 26. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc6653 27. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000000fccc4c3 28. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc3d92 29. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fcca080 30. ? @ 0x00007fbc6213eac3 31. ? @ 0x00007fbc621d0850 (version 25.3.6.10636.altinitytest (altinity build)) 2025.07.28 11:52:11.550151 [ 3283 ] {01b8614a-643d-46c3-a6ef-45f722a11426} executeQuery: Code: 219. DB::Exception: New table appeared in database being dropped or detached. Try again. (DATABASE_NOT_EMPTY) (version 25.3.6.10636.altinitytest (altinity build)) (from [::1]:33994) (comment: 02096_sample_by_tuple.sql) (in query: DROP DATABASE IF EXISTS test_9kfzxc3z SYNC ), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000000a074fcb 4. /build/src/Interpreters/DatabaseCatalog.cpp:608: DB::DatabaseCatalog::detachDatabase(std::shared_ptr, String const&, bool, bool) @ 0x00000000144f41b9 5. /build/src/Interpreters/InterpreterDropQuery.cpp:482: DB::InterpreterDropQuery::executeToDatabaseImpl(DB::ASTDropQuery const&, std::shared_ptr&, std::vector, DB::UUIDTag>, std::allocator, DB::UUIDTag>>>&) @ 0x00000000149179be 6. /build/src/Interpreters/InterpreterDropQuery.cpp:363: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x0000000014913988 7. /build/src/Interpreters/InterpreterDropQuery.cpp:99: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000014913142 8. /build/src/Interpreters/InterpreterDropQuery.cpp:72: DB::InterpreterDropQuery::execute() @ 0x0000000014912b65 9. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88dc9 10. /build/src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x0000000014c8ca7b 11. /build/src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000001686da12 12. /build/src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x0000000016870807 13. /build/src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x0000000016907e99 14. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 15. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 16. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 17. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 18. ? @ 0x00007fbc6213eac3 19. ? @ 0x00007fbc621d0850 2025.07.28 11:52:11.552291 [ 3283 ] {01b8614a-643d-46c3-a6ef-45f722a11426} 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. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000000a074fcb 4. /build/src/Interpreters/DatabaseCatalog.cpp:608: DB::DatabaseCatalog::detachDatabase(std::shared_ptr, String const&, bool, bool) @ 0x00000000144f41b9 5. /build/src/Interpreters/InterpreterDropQuery.cpp:482: DB::InterpreterDropQuery::executeToDatabaseImpl(DB::ASTDropQuery const&, std::shared_ptr&, std::vector, DB::UUIDTag>, std::allocator, DB::UUIDTag>>>&) @ 0x00000000149179be 6. /build/src/Interpreters/InterpreterDropQuery.cpp:363: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x0000000014913988 7. /build/src/Interpreters/InterpreterDropQuery.cpp:99: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000014913142 8. /build/src/Interpreters/InterpreterDropQuery.cpp:72: DB::InterpreterDropQuery::execute() @ 0x0000000014912b65 9. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88dc9 10. /build/src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x0000000014c8ca7b 11. /build/src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000001686da12 12. /build/src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x0000000016870807 13. /build/src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x0000000016907e99 14. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 15. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 16. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 17. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 18. ? @ 0x00007fbc6213eac3 19. ? @ 0x00007fbc621d0850 (version 25.3.6.10636.altinitytest (altinity build)) 2025.07.28 11:52:11.694673 [ 5825 ] {e1424adc-d106-4151-a5cf-dc839b24e256} executeQuery: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=23, jobs=4): While executing MergeTreeSelect(pool: ReadPool, algorithm: Thread). (CANNOT_SCHEDULE_TASK) (version 25.3.6.10636.altinitytest (altinity build)) (from [::1]:49976) (comment: 02240_protobuflist_format_persons.sh) (query 1, line 1) (in query: SELECT * FROM persons_02240 ORDER BY name FORMAT ProtobufList SETTINGS format_schema = '/repo/tests/queries/0_stateless/format_schemas/02240_protobuflist_format_persons_syntax2:Syntax2Person'), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000fccaeeb 4. /build/src/Common/ThreadPool.cpp:275: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000fccc813 5. /build/src/Common/ThreadPool.cpp:323: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fcc7bbc 6. /build/src/Common/ThreadPool.cpp:494: ThreadPoolImpl>::scheduleOrThrowOnError(std::function, Priority) @ 0x000000000fcc7a0e 7. /build/src/Common/threadPoolCallbackRunner.h:52: std::future> std::__function::__policy_invoker> (DB::MergeTreeMarksLoader::loadMarksAsync()::$_0&&, Priority)>::__call_impl[abi:se190107]> (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&&) @ 0x0000000016474731 8. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000016471940 9. /build/src/Storages/MergeTree/MergeTreeMarksLoader.cpp:83: DB::MergeTreeMarksLoader::startAsyncLoad() @ 0x000000001647173f 10. /build/src/Storages/MergeTree/MergeTreeReaderWide.cpp:294: DB::MergeTreeReaderWide::addStream(DB::ISerialization::SubstreamPath const&, String const&) @ 0x00000000164aa163 11. /build/src/Storages/MergeTree/MergeTreeReaderWide.cpp:251: void std::__function::__policy_invoker::__call_impl[abi:se190107] const&)::$_0, void (DB::ISerialization::SubstreamPath const&)>>(std::__function::__policy_storage const*, DB::ISerialization::SubstreamPath const&) @ 0x00000000164ab3ce 12. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000013cc00ff 13. /build/src/DataTypes/Serializations/ISerialization.cpp:104: DB::ISerialization::enumerateStreams(std::function const&, std::shared_ptr const&, COW::immutable_ptr const&) const @ 0x0000000013c7acfd 14. /build/src/Storages/MergeTree/MergeTreeReaderWide.cpp:255: DB::MergeTreeReaderWide::addStreams(DB::NameAndTypePair const&, std::shared_ptr const&) @ 0x00000000164a83c4 15. /build/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) @ 0x00000000164a81cc 16. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]&, 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&&) @ 0x00000000163cf0e0 17. /build/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 @ 0x00000000163ca51e 18. /build/src/Storages/MergeTree/MergeTreeReadTask.cpp:60: DB::MergeTreeReadTask::createReaders(std::shared_ptr const&, DB::MergeTreeReadTask::Extras const&, DB::MarkRanges const&) @ 0x00000000164b5386 19. /build/src/Storages/MergeTree/MergeTreeReadPoolBase.cpp:274: DB::MergeTreeReadPoolBase::createTask(std::shared_ptr, DB::MarkRanges, DB::MergeTreeReadTask*) const @ 0x0000000016e53b1f 20. /build/src/Storages/MergeTree/MergeTreeReadPool.cpp:159: DB::MergeTreeReadPool::getTask(unsigned long, DB::MergeTreeReadTask*) @ 0x0000000016e71eca 21. /build/src/Storages/MergeTree/MergeTreeSelectProcessor.cpp:191: DB::MergeTreeSelectProcessor::read() @ 0x00000000164c0b40 22. /build/src/Storages/MergeTree/MergeTreeSource.cpp:229: DB::MergeTreeSource::tryGenerate() @ 0x0000000016e43d69 23. /build/src/Processors/ISource.cpp:108: DB::ISource::work() @ 0x00000000169a21e7 24. /build/src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x00000000169bd00f 25. /build/src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x00000000169b2105 26. /build/src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeSingleThread(unsigned long) @ 0x00000000169b23be 27. /build/src/Processors/Executors/PipelineExecutor.cpp:416: void std::__function::__policy_invoker::__call_impl[abi:se190107]>(std::__function::__policy_storage const*) @ 0x00000000169b2e3f 28. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc6653 29. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000000fccc4c3 30. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc3d92 31. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fcca080 2025.07.28 11:52:11.847772 [ 5825 ] {} TCPHandler: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=23, jobs=4): While executing MergeTreeSelect(pool: ReadPool, algorithm: Thread). (CANNOT_SCHEDULE_TASK), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000fccaeeb 4. /build/src/Common/ThreadPool.cpp:275: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000fccc813 5. /build/src/Common/ThreadPool.cpp:323: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fcc7bbc 6. /build/src/Common/ThreadPool.cpp:494: ThreadPoolImpl>::scheduleOrThrowOnError(std::function, Priority) @ 0x000000000fcc7a0e 7. /build/src/Common/threadPoolCallbackRunner.h:52: std::future> std::__function::__policy_invoker> (DB::MergeTreeMarksLoader::loadMarksAsync()::$_0&&, Priority)>::__call_impl[abi:se190107]> (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&&) @ 0x0000000016474731 8. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000016471940 9. /build/src/Storages/MergeTree/MergeTreeMarksLoader.cpp:83: DB::MergeTreeMarksLoader::startAsyncLoad() @ 0x000000001647173f 10. /build/src/Storages/MergeTree/MergeTreeReaderWide.cpp:294: DB::MergeTreeReaderWide::addStream(DB::ISerialization::SubstreamPath const&, String const&) @ 0x00000000164aa163 11. /build/src/Storages/MergeTree/MergeTreeReaderWide.cpp:251: void std::__function::__policy_invoker::__call_impl[abi:se190107] const&)::$_0, void (DB::ISerialization::SubstreamPath const&)>>(std::__function::__policy_storage const*, DB::ISerialization::SubstreamPath const&) @ 0x00000000164ab3ce 12. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000013cc00ff 13. /build/src/DataTypes/Serializations/ISerialization.cpp:104: DB::ISerialization::enumerateStreams(std::function const&, std::shared_ptr const&, COW::immutable_ptr const&) const @ 0x0000000013c7acfd 14. /build/src/Storages/MergeTree/MergeTreeReaderWide.cpp:255: DB::MergeTreeReaderWide::addStreams(DB::NameAndTypePair const&, std::shared_ptr const&) @ 0x00000000164a83c4 15. /build/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) @ 0x00000000164a81cc 16. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]&, 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&&) @ 0x00000000163cf0e0 17. /build/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 @ 0x00000000163ca51e 18. /build/src/Storages/MergeTree/MergeTreeReadTask.cpp:60: DB::MergeTreeReadTask::createReaders(std::shared_ptr const&, DB::MergeTreeReadTask::Extras const&, DB::MarkRanges const&) @ 0x00000000164b5386 19. /build/src/Storages/MergeTree/MergeTreeReadPoolBase.cpp:274: DB::MergeTreeReadPoolBase::createTask(std::shared_ptr, DB::MarkRanges, DB::MergeTreeReadTask*) const @ 0x0000000016e53b1f 20. /build/src/Storages/MergeTree/MergeTreeReadPool.cpp:159: DB::MergeTreeReadPool::getTask(unsigned long, DB::MergeTreeReadTask*) @ 0x0000000016e71eca 21. /build/src/Storages/MergeTree/MergeTreeSelectProcessor.cpp:191: DB::MergeTreeSelectProcessor::read() @ 0x00000000164c0b40 22. /build/src/Storages/MergeTree/MergeTreeSource.cpp:229: DB::MergeTreeSource::tryGenerate() @ 0x0000000016e43d69 23. /build/src/Processors/ISource.cpp:108: DB::ISource::work() @ 0x00000000169a21e7 24. /build/src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x00000000169bd00f 25. /build/src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x00000000169b2105 26. /build/src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeSingleThread(unsigned long) @ 0x00000000169b23be 27. /build/src/Processors/Executors/PipelineExecutor.cpp:416: void std::__function::__policy_invoker::__call_impl[abi:se190107]>(std::__function::__policy_storage const*) @ 0x00000000169b2e3f 28. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc6653 29. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000000fccc4c3 30. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc3d92 31. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fcca080 Job's origin stack trace: 0. /build/src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000000fc33b84 1. /build/src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000000fcc2ea7 2. /build/src/Common/ThreadPool.cpp:401: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fcc7f1c 3. /build/src/Common/ThreadPool.cpp:494: ThreadPoolImpl>::scheduleOrThrowOnError(std::function, Priority) @ 0x000000000fcc7a0e 4. /build/src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::spawnThreadsImpl() @ 0x00000000169b2c0c 5. /build/src/Processors/Executors/PipelineExecutor.cpp:394: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x00000000169b0ba7 6. /build/src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x00000000169b03f4 7. /build/src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:se190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169bfeab 8. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc3d92 9. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fcca080 10. ? @ 0x00007fbc6213eac3 11. ? @ 0x00007fbc621d0850 Job's origin stack trace: 0. /build/src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000000fc33b84 1. /build/src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000000fcc2ea7 2. /build/src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fcc535c 3. /build/src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000000fcc584d 4. /build/src/Common/ThreadPool.h:279: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x00000000169bf193 5. /build/src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x00000000169bf518 6. /build/src/Server/TCPHandler.cpp:1237: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x00000000168f1525 7. /build/src/Server/TCPHandler.cpp:678: DB::TCPHandler::runImpl() @ 0x00000000168e68e5 8. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 9. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 10. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 11. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 12. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 13. ? @ 0x00007fbc6213eac3 14. ? @ 0x00007fbc621d0850 2025.07.28 11:52:12.077414 [ 3966 ] {} test_13.rmt2 (7f9b740d-015c-470e-8cc6-8ba33be0dc63): auto DB::StorageReplicatedMergeTree::processQueueEntry(ReplicatedMergeTreeQueue::SelectedEntryPtr)::(anonymous class)::operator()(LogEntryPtr &) const: Code: 86. DB::HTTPException: Received error from remote server http://146b4357c08d:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Ftest%2F01165%2Ftest_13%2Frmt%2Freplicas%2F1&part=20250728_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.6.10636.altinitytest (altinity build)) '. (RECEIVED_ERROR_FROM_REMOTE_IO_SERVER), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.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 const&, int&&, String const&, unsigned long&&, String const&) @ 0x000000000feda8d9 4. /build/src/IO/HTTPCommon.cpp:104: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x000000000feda6e2 5. /build/src/IO/HTTPCommon.cpp:93: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x000000000feda537 6. /build/src/IO/ReadWriteBufferFromHTTP.cpp:277: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x000000001184a4c4 7. /build/src/IO/ReadWriteBufferFromHTTP.cpp:285: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x000000001184a615 8. /build/src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x000000001184ae59 9. /build/src/IO/ReadWriteBufferFromHTTP.cpp:472: void std::__function::__policy_invoker::__call_impl[abi:se190107]>(std::__function::__policy_storage const*) @ 0x000000001184cedd 10. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001184858b 11. /build/src/IO/ReadWriteBufferFromHTTP.cpp:465: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x000000001184bf0b 12. /build/src/IO/ReadBuffer.h:60: DB::ReadBuffer::next() @ 0x000000000a148c7b 13. /build/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) @ 0x0000000011849fb2 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]>&)>&, 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&) @ 0x0000000011841980 15. /build/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) @ 0x000000001621208e 16. /build/src/Storages/StorageReplicatedMergeTree.cpp:5228: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl[abi:se190107] const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000015f9a5fe 17. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000015ed8bfd 18. /build/src/Storages/StorageReplicatedMergeTree.cpp:2514: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x0000000015ec9aab 19. /build/src/Storages/StorageReplicatedMergeTree.cpp:2349: DB::StorageReplicatedMergeTree::executeLogEntry(DB::ReplicatedMergeTreeLogEntry&) @ 0x0000000015eba91b 20. /build/src/Storages/StorageReplicatedMergeTree.cpp:3876: bool std::__function::__policy_invoker&)>::__call_impl[abi:se190107])::$_1, bool (std::shared_ptr&)>>(std::__function::__policy_storage const*, std::shared_ptr&) @ 0x0000000015f9837e 21. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000165d6fc3 22. /build/src/Storages/StorageReplicatedMergeTree.cpp:3872: DB::StorageReplicatedMergeTree::processQueueEntry(std::shared_ptr) @ 0x0000000015efc18a 23. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001624c1b2 24. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000162f9c70 25. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x00000000162fa55a 26. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc6653 27. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000000fccc4c3 28. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc3d92 29. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fcca080 30. ? @ 0x00007fbc6213eac3 31. ? @ 0x00007fbc621d0850 (version 25.3.6.10636.altinitytest (altinity build)) 2025.07.28 11:52:12.203972 [ 3283 ] {92691c75-7a00-4016-8ec6-91673c4b2756} executeQuery: Code: 219. DB::Exception: New table appeared in database being dropped or detached. Try again. (DATABASE_NOT_EMPTY) (version 25.3.6.10636.altinitytest (altinity build)) (from [::1]:34010) (comment: 02240_protobuflist_format_persons.sh) (in query: DROP DATABASE IF EXISTS test_zxywfurq SYNC ), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000000a074fcb 4. /build/src/Interpreters/DatabaseCatalog.cpp:608: DB::DatabaseCatalog::detachDatabase(std::shared_ptr, String const&, bool, bool) @ 0x00000000144f41b9 5. /build/src/Interpreters/InterpreterDropQuery.cpp:482: DB::InterpreterDropQuery::executeToDatabaseImpl(DB::ASTDropQuery const&, std::shared_ptr&, std::vector, DB::UUIDTag>, std::allocator, DB::UUIDTag>>>&) @ 0x00000000149179be 6. /build/src/Interpreters/InterpreterDropQuery.cpp:363: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x0000000014913988 7. /build/src/Interpreters/InterpreterDropQuery.cpp:99: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000014913142 8. /build/src/Interpreters/InterpreterDropQuery.cpp:72: DB::InterpreterDropQuery::execute() @ 0x0000000014912b65 9. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88dc9 10. /build/src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x0000000014c8ca7b 11. /build/src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000001686da12 12. /build/src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x0000000016870807 13. /build/src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x0000000016907e99 14. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 15. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 16. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 17. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 18. ? @ 0x00007fbc6213eac3 19. ? @ 0x00007fbc621d0850 2025.07.28 11:52:12.205353 [ 3283 ] {92691c75-7a00-4016-8ec6-91673c4b2756} 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. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000000a074fcb 4. /build/src/Interpreters/DatabaseCatalog.cpp:608: DB::DatabaseCatalog::detachDatabase(std::shared_ptr, String const&, bool, bool) @ 0x00000000144f41b9 5. /build/src/Interpreters/InterpreterDropQuery.cpp:482: DB::InterpreterDropQuery::executeToDatabaseImpl(DB::ASTDropQuery const&, std::shared_ptr&, std::vector, DB::UUIDTag>, std::allocator, DB::UUIDTag>>>&) @ 0x00000000149179be 6. /build/src/Interpreters/InterpreterDropQuery.cpp:363: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x0000000014913988 7. /build/src/Interpreters/InterpreterDropQuery.cpp:99: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000014913142 8. /build/src/Interpreters/InterpreterDropQuery.cpp:72: DB::InterpreterDropQuery::execute() @ 0x0000000014912b65 9. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88dc9 10. /build/src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x0000000014c8ca7b 11. /build/src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000001686da12 12. /build/src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x0000000016870807 13. /build/src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x0000000016907e99 14. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 15. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 16. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 17. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 18. ? @ 0x00007fbc6213eac3 19. ? @ 0x00007fbc621d0850 (version 25.3.6.10636.altinitytest (altinity build)) 2025.07.28 11:52:12.576424 [ 17210 ] {} 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. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Access/AccessControl.cpp:646: DB::AccessControl::authenticate(DB::Credentials const&, Poco::Net::IPAddress const&, DB::ClientInfo const&) const @ 0x0000000013727552 4. /build/src/Interpreters/Session.cpp:371: DB::Session::authenticate(DB::Credentials const&, Poco::Net::SocketAddress const&, std::vector> const&) @ 0x0000000014a6dd4d 5. /build/src/Interpreters/Session.cpp:350: DB::Session::authenticate(String const&, String const&, Poco::Net::SocketAddress const&, std::vector> const&) @ 0x0000000014a6d7b0 6. /build/src/Server/TCPHandler.cpp:1798: DB::TCPHandler::receiveHello() @ 0x00000000168ed801 7. /build/src/Server/TCPHandler.cpp:339: DB::TCPHandler::runImpl() @ 0x00000000168e59e6 8. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 9. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 10. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 11. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 12. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 13. ? @ 0x00007fbc6213eac3 14. ? @ 0x00007fbc621d0850 (version 25.3.6.10636.altinitytest (altinity build)) 2025.07.28 11:52:12.584467 [ 17210 ] {} 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. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Access/AccessControl.cpp:646: DB::AccessControl::authenticate(DB::Credentials const&, Poco::Net::IPAddress const&, DB::ClientInfo const&) const @ 0x0000000013727552 4. /build/src/Interpreters/Session.cpp:371: DB::Session::authenticate(DB::Credentials const&, Poco::Net::SocketAddress const&, std::vector> const&) @ 0x0000000014a6dd4d 5. /build/src/Interpreters/Session.cpp:350: DB::Session::authenticate(String const&, String const&, Poco::Net::SocketAddress const&, std::vector> const&) @ 0x0000000014a6d7b0 6. /build/src/Server/TCPHandler.cpp:1798: DB::TCPHandler::receiveHello() @ 0x00000000168ed801 7. /build/src/Server/TCPHandler.cpp:339: DB::TCPHandler::runImpl() @ 0x00000000168e59e6 8. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 9. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 10. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 11. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 12. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 13. ? @ 0x00007fbc6213eac3 14. ? @ 0x00007fbc621d0850 (version 25.3.6.10636.altinitytest (altinity build)) 2025.07.28 11:52:12.699524 [ 17210 ] {} 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. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Access/AccessControl.cpp:646: DB::AccessControl::authenticate(DB::Credentials const&, Poco::Net::IPAddress const&, DB::ClientInfo const&) const @ 0x0000000013727552 4. /build/src/Interpreters/Session.cpp:371: DB::Session::authenticate(DB::Credentials const&, Poco::Net::SocketAddress const&, std::vector> const&) @ 0x0000000014a6dd4d 5. /build/src/Interpreters/Session.cpp:350: DB::Session::authenticate(String const&, String const&, Poco::Net::SocketAddress const&, std::vector> const&) @ 0x0000000014a6d7b0 6. /build/src/Server/TCPHandler.cpp:1798: DB::TCPHandler::receiveHello() @ 0x00000000168ed801 7. /build/src/Server/TCPHandler.cpp:339: DB::TCPHandler::runImpl() @ 0x00000000168e59e6 8. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 9. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 10. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 11. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 12. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 13. ? @ 0x00007fbc6213eac3 14. ? @ 0x00007fbc621d0850 (version 25.3.6.10636.altinitytest (altinity build)) 2025.07.28 11:52:12.700247 [ 17210 ] {} 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. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Access/AccessControl.cpp:646: DB::AccessControl::authenticate(DB::Credentials const&, Poco::Net::IPAddress const&, DB::ClientInfo const&) const @ 0x0000000013727552 4. /build/src/Interpreters/Session.cpp:371: DB::Session::authenticate(DB::Credentials const&, Poco::Net::SocketAddress const&, std::vector> const&) @ 0x0000000014a6dd4d 5. /build/src/Interpreters/Session.cpp:350: DB::Session::authenticate(String const&, String const&, Poco::Net::SocketAddress const&, std::vector> const&) @ 0x0000000014a6d7b0 6. /build/src/Server/TCPHandler.cpp:1798: DB::TCPHandler::receiveHello() @ 0x00000000168ed801 7. /build/src/Server/TCPHandler.cpp:339: DB::TCPHandler::runImpl() @ 0x00000000168e59e6 8. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 9. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 10. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 11. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 12. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 13. ? @ 0x00007fbc6213eac3 14. ? @ 0x00007fbc621d0850 (version 25.3.6.10636.altinitytest (altinity build)) 2025.07.28 11:52:12.867951 [ 5747 ] {} 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. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Access/AccessControl.cpp:646: DB::AccessControl::authenticate(DB::Credentials const&, Poco::Net::IPAddress const&, DB::ClientInfo const&) const @ 0x0000000013727552 4. /build/src/Interpreters/Session.cpp:371: DB::Session::authenticate(DB::Credentials const&, Poco::Net::SocketAddress const&, std::vector> const&) @ 0x0000000014a6dd4d 5. /build/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) @ 0x0000000016910eed 6. /build/src/Server/HTTPHandler.cpp:208: DB::HTTPHandler::authenticateUser(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&) @ 0x000000001686a6b6 7. /build/src/Server/HTTPHandler.cpp:224: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000001686aaa7 8. /build/src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x0000000016870807 9. /build/src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x0000000016907e99 10. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 11. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 12. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 13. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 14. ? @ 0x00007fbc6213eac3 15. ? @ 0x00007fbc621d0850 (version 25.3.6.10636.altinitytest (altinity build)) 2025.07.28 11:52:12.867898 [ 3960 ] {} test_13.rmt2 (7f9b740d-015c-470e-8cc6-8ba33be0dc63): auto DB::StorageReplicatedMergeTree::processQueueEntry(ReplicatedMergeTreeQueue::SelectedEntryPtr)::(anonymous class)::operator()(LogEntryPtr &) const: Code: 86. DB::HTTPException: Received error from remote server http://146b4357c08d:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Ftest%2F01165%2Ftest_13%2Frmt%2Freplicas%2F1&part=20250728_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.6.10636.altinitytest (altinity build)) '. (RECEIVED_ERROR_FROM_REMOTE_IO_SERVER), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.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 const&, int&&, String const&, unsigned long&&, String const&) @ 0x000000000feda8d9 4. /build/src/IO/HTTPCommon.cpp:104: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x000000000feda6e2 5. /build/src/IO/HTTPCommon.cpp:93: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x000000000feda537 6. /build/src/IO/ReadWriteBufferFromHTTP.cpp:277: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x000000001184a4c4 7. /build/src/IO/ReadWriteBufferFromHTTP.cpp:285: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x000000001184a615 8. /build/src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x000000001184ae59 9. /build/src/IO/ReadWriteBufferFromHTTP.cpp:472: void std::__function::__policy_invoker::__call_impl[abi:se190107]>(std::__function::__policy_storage const*) @ 0x000000001184cedd 10. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001184858b 11. /build/src/IO/ReadWriteBufferFromHTTP.cpp:465: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x000000001184bf0b 12. /build/src/IO/ReadBuffer.h:60: DB::ReadBuffer::next() @ 0x000000000a148c7b 13. /build/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) @ 0x0000000011849fb2 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]>&)>&, 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&) @ 0x0000000011841980 15. /build/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) @ 0x000000001621208e 16. /build/src/Storages/StorageReplicatedMergeTree.cpp:5228: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl[abi:se190107] const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000015f9a5fe 17. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000015ed8bfd 18. /build/src/Storages/StorageReplicatedMergeTree.cpp:2514: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x0000000015ec9aab 19. /build/src/Storages/StorageReplicatedMergeTree.cpp:2349: DB::StorageReplicatedMergeTree::executeLogEntry(DB::ReplicatedMergeTreeLogEntry&) @ 0x0000000015eba91b 20. /build/src/Storages/StorageReplicatedMergeTree.cpp:3876: bool std::__function::__policy_invoker&)>::__call_impl[abi:se190107])::$_1, bool (std::shared_ptr&)>>(std::__function::__policy_storage const*, std::shared_ptr&) @ 0x0000000015f9837e 21. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000165d6fc3 22. /build/src/Storages/StorageReplicatedMergeTree.cpp:3872: DB::StorageReplicatedMergeTree::processQueueEntry(std::shared_ptr) @ 0x0000000015efc18a 23. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001624c1b2 24. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000162f9c70 25. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x00000000162fa55a 26. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc6653 27. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000000fccc4c3 28. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc3d92 29. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fcca080 30. ? @ 0x00007fbc6213eac3 31. ? @ 0x00007fbc621d0850 (version 25.3.6.10636.altinitytest (altinity build)) 2025.07.28 11:52:12.894368 [ 17611 ] {} 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. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Access/AccessControl.cpp:646: DB::AccessControl::authenticate(DB::Credentials const&, Poco::Net::IPAddress const&, DB::ClientInfo const&) const @ 0x0000000013727552 4. /build/src/Interpreters/Session.cpp:371: DB::Session::authenticate(DB::Credentials const&, Poco::Net::SocketAddress const&, std::vector> const&) @ 0x0000000014a6dd4d 5. /build/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) @ 0x0000000016910eed 6. /build/src/Server/HTTPHandler.cpp:208: DB::HTTPHandler::authenticateUser(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&) @ 0x000000001686a6b6 7. /build/src/Server/HTTPHandler.cpp:224: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000001686aaa7 8. /build/src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x0000000016870807 9. /build/src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x0000000016907e99 10. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 11. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 12. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 13. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 14. ? @ 0x00007fbc6213eac3 15. ? @ 0x00007fbc621d0850 (version 25.3.6.10636.altinitytest (altinity build)) 2025.07.28 11:52:13.710398 [ 7630 ] {c338962b-b974-49dc-808d-4483b8f42a1c} executeQuery: Code: 47. DB::Exception: Unknown expression or function identifier `x` in scope x = 1. (UNKNOWN_IDENTIFIER) (version 25.3.6.10636.altinitytest (altinity build)) (from [::1]:49970) (comment: 01825_new_type_json_3.gen.sql) (query 7, line 19) (in query: SELECT id, data, JSONAllPathsWithTypes(data) FROM t_json_3 ORDER BY id;), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.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&&) @ 0x000000001404b3b9 4. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3771: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000001401b849 5. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3980: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000014018e31 6. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:2925: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000001402fcbd 7. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3838: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000014019a9e 8. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:209: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000001401270e 9. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000014011fce 10. /build/src/Planner/Utils.cpp:458: DB::buildFilterInfo(std::shared_ptr, std::shared_ptr const&, std::shared_ptr&, std::unordered_set, std::equal_to, std::allocator>) @ 0x0000000013fe8bcf 11. /build/src/Planner/PlannerJoinTree.cpp:535: DB::(anonymous namespace)::buildQueryPlanForTableExpression(std::shared_ptr, std::shared_ptr const&, DB::SelectQueryInfo const&, DB::SelectQueryOptions const&, std::shared_ptr&, bool, bool) @ 0x00000000149956d3 12. /build/src/Planner/PlannerJoinTree.cpp:2252: DB::buildJoinTreeQueryPlan(std::shared_ptr const&, DB::SelectQueryInfo const&, DB::SelectQueryOptions&, std::unordered_set, std::equal_to, std::allocator> const&, std::shared_ptr&) @ 0x000000001498e109 13. /build/src/Planner/Planner.cpp:1553: DB::Planner::buildPlanForQueryNode() @ 0x0000000014979dae 14. /build/src/Planner/Planner.cpp:1308: DB::Planner::buildQueryPlanIfNeeded() @ 0x000000001497685c 15. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:255: DB::InterpreterSelectQueryAnalyzer::getQueryPlan() @ 0x000000001497476d 16. /build/src/Interpreters/executeQuery.cpp:1405: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88806 17. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 18. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 19. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 20. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 21. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 22. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 23. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 24. ? @ 0x00007fbc6213eac3 25. ? @ 0x00007fbc621d0850 2025.07.28 11:52:13.711756 [ 3976 ] {} test_13.rmt2 (7f9b740d-015c-470e-8cc6-8ba33be0dc63): auto DB::StorageReplicatedMergeTree::processQueueEntry(ReplicatedMergeTreeQueue::SelectedEntryPtr)::(anonymous class)::operator()(LogEntryPtr &) const: Code: 86. DB::HTTPException: Received error from remote server http://146b4357c08d:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Ftest%2F01165%2Ftest_13%2Frmt%2Freplicas%2F1&part=20250728_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.6.10636.altinitytest (altinity build)) '. (RECEIVED_ERROR_FROM_REMOTE_IO_SERVER), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.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 const&, int&&, String const&, unsigned long&&, String const&) @ 0x000000000feda8d9 4. /build/src/IO/HTTPCommon.cpp:104: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x000000000feda6e2 5. /build/src/IO/HTTPCommon.cpp:93: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x000000000feda537 6. /build/src/IO/ReadWriteBufferFromHTTP.cpp:277: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x000000001184a4c4 7. /build/src/IO/ReadWriteBufferFromHTTP.cpp:285: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x000000001184a615 8. /build/src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x000000001184ae59 9. /build/src/IO/ReadWriteBufferFromHTTP.cpp:472: void std::__function::__policy_invoker::__call_impl[abi:se190107]>(std::__function::__policy_storage const*) @ 0x000000001184cedd 10. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001184858b 11. /build/src/IO/ReadWriteBufferFromHTTP.cpp:465: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x000000001184bf0b 12. /build/src/IO/ReadBuffer.h:60: DB::ReadBuffer::next() @ 0x000000000a148c7b 13. /build/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) @ 0x0000000011849fb2 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]>&)>&, 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&) @ 0x0000000011841980 15. /build/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) @ 0x000000001621208e 16. /build/src/Storages/StorageReplicatedMergeTree.cpp:5228: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl[abi:se190107] const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000015f9a5fe 17. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000015ed8bfd 18. /build/src/Storages/StorageReplicatedMergeTree.cpp:2514: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x0000000015ec9aab 19. /build/src/Storages/StorageReplicatedMergeTree.cpp:2349: DB::StorageReplicatedMergeTree::executeLogEntry(DB::ReplicatedMergeTreeLogEntry&) @ 0x0000000015eba91b 20. /build/src/Storages/StorageReplicatedMergeTree.cpp:3876: bool std::__function::__policy_invoker&)>::__call_impl[abi:se190107])::$_1, bool (std::shared_ptr&)>>(std::__function::__policy_storage const*, std::shared_ptr&) @ 0x0000000015f9837e 21. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000165d6fc3 22. /build/src/Storages/StorageReplicatedMergeTree.cpp:3872: DB::StorageReplicatedMergeTree::processQueueEntry(std::shared_ptr) @ 0x0000000015efc18a 23. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001624c1b2 24. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000162f9c70 25. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x00000000162fa55a 26. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc6653 27. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000000fccc4c3 28. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc3d92 29. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fcca080 30. ? @ 0x00007fbc6213eac3 31. ? @ 0x00007fbc621d0850 (version 25.3.6.10636.altinitytest (altinity build)) 2025.07.28 11:52:13.729710 [ 7630 ] {} TCPHandler: Code: 47. DB::Exception: Unknown expression or function identifier `x` in scope x = 1. (UNKNOWN_IDENTIFIER), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.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&&) @ 0x000000001404b3b9 4. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3771: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000001401b849 5. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3980: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000014018e31 6. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:2925: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000001402fcbd 7. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3838: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000014019a9e 8. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:209: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000001401270e 9. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000014011fce 10. /build/src/Planner/Utils.cpp:458: DB::buildFilterInfo(std::shared_ptr, std::shared_ptr const&, std::shared_ptr&, std::unordered_set, std::equal_to, std::allocator>) @ 0x0000000013fe8bcf 11. /build/src/Planner/PlannerJoinTree.cpp:535: DB::(anonymous namespace)::buildQueryPlanForTableExpression(std::shared_ptr, std::shared_ptr const&, DB::SelectQueryInfo const&, DB::SelectQueryOptions const&, std::shared_ptr&, bool, bool) @ 0x00000000149956d3 12. /build/src/Planner/PlannerJoinTree.cpp:2252: DB::buildJoinTreeQueryPlan(std::shared_ptr const&, DB::SelectQueryInfo const&, DB::SelectQueryOptions&, std::unordered_set, std::equal_to, std::allocator> const&, std::shared_ptr&) @ 0x000000001498e109 13. /build/src/Planner/Planner.cpp:1553: DB::Planner::buildPlanForQueryNode() @ 0x0000000014979dae 14. /build/src/Planner/Planner.cpp:1308: DB::Planner::buildQueryPlanIfNeeded() @ 0x000000001497685c 15. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:255: DB::InterpreterSelectQueryAnalyzer::getQueryPlan() @ 0x000000001497476d 16. /build/src/Interpreters/executeQuery.cpp:1405: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88806 17. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 18. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 19. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 20. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 21. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 22. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 23. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 24. ? @ 0x00007fbc6213eac3 25. ? @ 0x00007fbc621d0850 2025.07.28 11:52:14.402772 [ 3960 ] {} test_13.rmt2 (7f9b740d-015c-470e-8cc6-8ba33be0dc63): auto DB::StorageReplicatedMergeTree::processQueueEntry(ReplicatedMergeTreeQueue::SelectedEntryPtr)::(anonymous class)::operator()(LogEntryPtr &) const: Code: 86. DB::HTTPException: Received error from remote server http://146b4357c08d:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Ftest%2F01165%2Ftest_13%2Frmt%2Freplicas%2F1&part=20250728_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.6.10636.altinitytest (altinity build)) '. (RECEIVED_ERROR_FROM_REMOTE_IO_SERVER), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.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 const&, int&&, String const&, unsigned long&&, String const&) @ 0x000000000feda8d9 4. /build/src/IO/HTTPCommon.cpp:104: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x000000000feda6e2 5. /build/src/IO/HTTPCommon.cpp:93: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x000000000feda537 6. /build/src/IO/ReadWriteBufferFromHTTP.cpp:277: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x000000001184a4c4 7. /build/src/IO/ReadWriteBufferFromHTTP.cpp:285: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x000000001184a615 8. /build/src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x000000001184ae59 9. /build/src/IO/ReadWriteBufferFromHTTP.cpp:472: void std::__function::__policy_invoker::__call_impl[abi:se190107]>(std::__function::__policy_storage const*) @ 0x000000001184cedd 10. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001184858b 11. /build/src/IO/ReadWriteBufferFromHTTP.cpp:465: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x000000001184bf0b 12. /build/src/IO/ReadBuffer.h:60: DB::ReadBuffer::next() @ 0x000000000a148c7b 13. /build/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) @ 0x0000000011849fb2 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]>&)>&, 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&) @ 0x0000000011841980 15. /build/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) @ 0x000000001621208e 16. /build/src/Storages/StorageReplicatedMergeTree.cpp:5228: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl[abi:se190107] const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000015f9a5fe 17. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000015ed8bfd 18. /build/src/Storages/StorageReplicatedMergeTree.cpp:2514: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x0000000015ec9aab 19. /build/src/Storages/StorageReplicatedMergeTree.cpp:2349: DB::StorageReplicatedMergeTree::executeLogEntry(DB::ReplicatedMergeTreeLogEntry&) @ 0x0000000015eba91b 20. /build/src/Storages/StorageReplicatedMergeTree.cpp:3876: bool std::__function::__policy_invoker&)>::__call_impl[abi:se190107])::$_1, bool (std::shared_ptr&)>>(std::__function::__policy_storage const*, std::shared_ptr&) @ 0x0000000015f9837e 21. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000165d6fc3 22. /build/src/Storages/StorageReplicatedMergeTree.cpp:3872: DB::StorageReplicatedMergeTree::processQueueEntry(std::shared_ptr) @ 0x0000000015efc18a 23. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001624c1b2 24. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000162f9c70 25. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x00000000162fa55a 26. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc6653 27. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000000fccc4c3 28. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc3d92 29. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fcca080 30. ? @ 0x00007fbc6213eac3 31. ? @ 0x00007fbc621d0850 (version 25.3.6.10636.altinitytest (altinity build)) 2025.07.28 11:52:14.571281 [ 17256 ] {2b7608a6-9f8d-4d49-b853-0e78f3de46e8} executeQuery: Code: 60. DB::Exception: Table default.id does not exist: While processing 1 IN (id). (UNKNOWN_TABLE) (version 25.3.6.10636.altinitytest (altinity build)) (from [::1]:58170) (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. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000a06a8eb 4. /build/src/Databases/IDatabase.cpp:41: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x0000000013dd565f 5. /build/src/Interpreters/DatabaseCatalog.cpp:442: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x00000000144f0869 6. /build/src/Interpreters/DatabaseCatalog.cpp:976: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x00000000144f6c88 7. /build/src/Interpreters/interpretSubquery.cpp:108: DB::interpretSubquery(std::shared_ptr const&, std::shared_ptr, std::vector> const&, DB::SelectQueryOptions const&) @ 0x0000000014ca52d7 8. /build/src/Interpreters/interpretSubquery.cpp:37: DB::interpretSubquery(std::shared_ptr const&, std::shared_ptr, unsigned long, std::vector> const&) @ 0x0000000014ca49c5 9. /build/src/Interpreters/ActionsVisitor.cpp:1516: DB::ActionsMatcher::makeSet(DB::ASTFunction const&, DB::ActionsMatcher::Data&, bool) @ 0x000000001455d045 10. /build/src/Interpreters/ActionsVisitor.cpp:999: DB::ActionsMatcher::visit(DB::ASTFunction const&, std::shared_ptr const&, DB::ActionsMatcher::Data&) @ 0x0000000014554175 11. /build/src/Interpreters/InDepthNodeVisitor.h:71: DB::InDepthNodeVisitor const>::doVisit(std::shared_ptr const&) @ 0x000000001454b195 12. /build/src/Interpreters/InDepthNodeVisitor.h:61: DB::ExpressionAnalyzer::getRootActions(std::shared_ptr const&, bool, DB::ActionsDAG&, bool) @ 0x0000000014528f28 13. /build/src/Interpreters/ExpressionAnalyzer.cpp:1867: DB::ExpressionAnalyzer::getActionsDAG(bool, bool) @ 0x00000000145381d6 14. /build/src/Interpreters/ExpressionAnalyzer.cpp:1902: DB::ExpressionAnalyzer::getActions(bool, bool, DB::CompileExpressions) @ 0x0000000014538609 15. /build/src/Storages/StorageDistributed.cpp:266: DB::(anonymous namespace)::buildShardingKeyExpression(std::shared_ptr const&, std::shared_ptr, DB::NamesAndTypesList const&, bool) @ 0x0000000015d5e6aa 16. /build/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) @ 0x0000000015d5cf4d 17. /build/contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: std::shared_ptr std::allocate_shared[abi:se190107], 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&&) @ 0x0000000011809909 18. /build/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 @ 0x0000000011805a50 19. /build/src/TableFunctions/ITableFunction.cpp:36: DB::ITableFunction::execute(std::shared_ptr const&, std::shared_ptr, String const&, DB::ColumnsDescription, bool, bool) const @ 0x00000000131e9fc3 20. /build/src/Interpreters/Context.cpp:2501: DB::Context::executeTableFunction(std::shared_ptr const&, std::shared_ptr const&) @ 0x00000000144345b2 21. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:4975: DB::QueryAnalyzer::resolveTableFunction(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&, bool) @ 0x000000001401e9f9 22. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5342: DB::QueryAnalyzer::resolveQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&) @ 0x00000000140452bf 23. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5597: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000140136f0 24. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000140127f9 25. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000014011fce 26. /build/src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000001406ce8a 27. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000014973b42 28. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000001497268d 29. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000014974d24 30. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001492924b 31. /build/src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88641 2025.07.28 11:52:14.582420 [ 17256 ] {} 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. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000a06a8eb 4. /build/src/Databases/IDatabase.cpp:41: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x0000000013dd565f 5. /build/src/Interpreters/DatabaseCatalog.cpp:442: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x00000000144f0869 6. /build/src/Interpreters/DatabaseCatalog.cpp:976: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x00000000144f6c88 7. /build/src/Interpreters/interpretSubquery.cpp:108: DB::interpretSubquery(std::shared_ptr const&, std::shared_ptr, std::vector> const&, DB::SelectQueryOptions const&) @ 0x0000000014ca52d7 8. /build/src/Interpreters/interpretSubquery.cpp:37: DB::interpretSubquery(std::shared_ptr const&, std::shared_ptr, unsigned long, std::vector> const&) @ 0x0000000014ca49c5 9. /build/src/Interpreters/ActionsVisitor.cpp:1516: DB::ActionsMatcher::makeSet(DB::ASTFunction const&, DB::ActionsMatcher::Data&, bool) @ 0x000000001455d045 10. /build/src/Interpreters/ActionsVisitor.cpp:999: DB::ActionsMatcher::visit(DB::ASTFunction const&, std::shared_ptr const&, DB::ActionsMatcher::Data&) @ 0x0000000014554175 11. /build/src/Interpreters/InDepthNodeVisitor.h:71: DB::InDepthNodeVisitor const>::doVisit(std::shared_ptr const&) @ 0x000000001454b195 12. /build/src/Interpreters/InDepthNodeVisitor.h:61: DB::ExpressionAnalyzer::getRootActions(std::shared_ptr const&, bool, DB::ActionsDAG&, bool) @ 0x0000000014528f28 13. /build/src/Interpreters/ExpressionAnalyzer.cpp:1867: DB::ExpressionAnalyzer::getActionsDAG(bool, bool) @ 0x00000000145381d6 14. /build/src/Interpreters/ExpressionAnalyzer.cpp:1902: DB::ExpressionAnalyzer::getActions(bool, bool, DB::CompileExpressions) @ 0x0000000014538609 15. /build/src/Storages/StorageDistributed.cpp:266: DB::(anonymous namespace)::buildShardingKeyExpression(std::shared_ptr const&, std::shared_ptr, DB::NamesAndTypesList const&, bool) @ 0x0000000015d5e6aa 16. /build/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) @ 0x0000000015d5cf4d 17. /build/contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: std::shared_ptr std::allocate_shared[abi:se190107], 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&&) @ 0x0000000011809909 18. /build/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 @ 0x0000000011805a50 19. /build/src/TableFunctions/ITableFunction.cpp:36: DB::ITableFunction::execute(std::shared_ptr const&, std::shared_ptr, String const&, DB::ColumnsDescription, bool, bool) const @ 0x00000000131e9fc3 20. /build/src/Interpreters/Context.cpp:2501: DB::Context::executeTableFunction(std::shared_ptr const&, std::shared_ptr const&) @ 0x00000000144345b2 21. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:4975: DB::QueryAnalyzer::resolveTableFunction(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&, bool) @ 0x000000001401e9f9 22. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5342: DB::QueryAnalyzer::resolveQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&) @ 0x00000000140452bf 23. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5597: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000140136f0 24. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000140127f9 25. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000014011fce 26. /build/src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000001406ce8a 27. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000014973b42 28. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000001497268d 29. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000014974d24 30. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001492924b 31. /build/src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88641 2025.07.28 11:52:14.775612 [ 17256 ] {3aaea0ab-c4c2-4514-b68c-fa6def5e6571} executeQuery: Code: 60. DB::Exception: Table default.dummy does not exist: While processing 1 IN (dummy). (UNKNOWN_TABLE) (version 25.3.6.10636.altinitytest (altinity build)) (from [::1]:58170) (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. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000a06a8eb 4. /build/src/Databases/IDatabase.cpp:41: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x0000000013dd565f 5. /build/src/Interpreters/DatabaseCatalog.cpp:442: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x00000000144f0869 6. /build/src/Interpreters/DatabaseCatalog.cpp:976: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x00000000144f6c88 7. /build/src/Interpreters/interpretSubquery.cpp:108: DB::interpretSubquery(std::shared_ptr const&, std::shared_ptr, std::vector> const&, DB::SelectQueryOptions const&) @ 0x0000000014ca52d7 8. /build/src/Interpreters/interpretSubquery.cpp:37: DB::interpretSubquery(std::shared_ptr const&, std::shared_ptr, unsigned long, std::vector> const&) @ 0x0000000014ca49c5 9. /build/src/Interpreters/ActionsVisitor.cpp:1516: DB::ActionsMatcher::makeSet(DB::ASTFunction const&, DB::ActionsMatcher::Data&, bool) @ 0x000000001455d045 10. /build/src/Interpreters/ActionsVisitor.cpp:999: DB::ActionsMatcher::visit(DB::ASTFunction const&, std::shared_ptr const&, DB::ActionsMatcher::Data&) @ 0x0000000014554175 11. /build/src/Interpreters/InDepthNodeVisitor.h:71: DB::InDepthNodeVisitor const>::doVisit(std::shared_ptr const&) @ 0x000000001454b195 12. /build/src/Interpreters/InDepthNodeVisitor.h:61: DB::ExpressionAnalyzer::getRootActions(std::shared_ptr const&, bool, DB::ActionsDAG&, bool) @ 0x0000000014528f28 13. /build/src/Interpreters/ExpressionAnalyzer.cpp:1867: DB::ExpressionAnalyzer::getActionsDAG(bool, bool) @ 0x00000000145381d6 14. /build/src/Interpreters/ExpressionAnalyzer.cpp:1902: DB::ExpressionAnalyzer::getActions(bool, bool, DB::CompileExpressions) @ 0x0000000014538609 15. /build/src/Storages/StorageDistributed.cpp:266: DB::(anonymous namespace)::buildShardingKeyExpression(std::shared_ptr const&, std::shared_ptr, DB::NamesAndTypesList const&, bool) @ 0x0000000015d5e6aa 16. /build/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) @ 0x0000000015d5cf4d 17. /build/contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: std::shared_ptr std::allocate_shared[abi:se190107], 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&&) @ 0x0000000011809909 18. /build/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 @ 0x0000000011805a50 19. /build/src/TableFunctions/ITableFunction.cpp:36: DB::ITableFunction::execute(std::shared_ptr const&, std::shared_ptr, String const&, DB::ColumnsDescription, bool, bool) const @ 0x00000000131e9fc3 20. /build/src/Interpreters/Context.cpp:2501: DB::Context::executeTableFunction(std::shared_ptr const&, std::shared_ptr const&) @ 0x00000000144345b2 21. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:4975: DB::QueryAnalyzer::resolveTableFunction(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&, bool) @ 0x000000001401e9f9 22. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5342: DB::QueryAnalyzer::resolveQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&) @ 0x00000000140452bf 23. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5597: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000140136f0 24. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000140127f9 25. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000014011fce 26. /build/src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000001406ce8a 27. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000014973b42 28. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000001497268d 29. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000014974d24 30. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001492924b 31. /build/src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88641 2025.07.28 11:52:14.785785 [ 17256 ] {} 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. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000a06a8eb 4. /build/src/Databases/IDatabase.cpp:41: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x0000000013dd565f 5. /build/src/Interpreters/DatabaseCatalog.cpp:442: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x00000000144f0869 6. /build/src/Interpreters/DatabaseCatalog.cpp:976: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x00000000144f6c88 7. /build/src/Interpreters/interpretSubquery.cpp:108: DB::interpretSubquery(std::shared_ptr const&, std::shared_ptr, std::vector> const&, DB::SelectQueryOptions const&) @ 0x0000000014ca52d7 8. /build/src/Interpreters/interpretSubquery.cpp:37: DB::interpretSubquery(std::shared_ptr const&, std::shared_ptr, unsigned long, std::vector> const&) @ 0x0000000014ca49c5 9. /build/src/Interpreters/ActionsVisitor.cpp:1516: DB::ActionsMatcher::makeSet(DB::ASTFunction const&, DB::ActionsMatcher::Data&, bool) @ 0x000000001455d045 10. /build/src/Interpreters/ActionsVisitor.cpp:999: DB::ActionsMatcher::visit(DB::ASTFunction const&, std::shared_ptr const&, DB::ActionsMatcher::Data&) @ 0x0000000014554175 11. /build/src/Interpreters/InDepthNodeVisitor.h:71: DB::InDepthNodeVisitor const>::doVisit(std::shared_ptr const&) @ 0x000000001454b195 12. /build/src/Interpreters/InDepthNodeVisitor.h:61: DB::ExpressionAnalyzer::getRootActions(std::shared_ptr const&, bool, DB::ActionsDAG&, bool) @ 0x0000000014528f28 13. /build/src/Interpreters/ExpressionAnalyzer.cpp:1867: DB::ExpressionAnalyzer::getActionsDAG(bool, bool) @ 0x00000000145381d6 14. /build/src/Interpreters/ExpressionAnalyzer.cpp:1902: DB::ExpressionAnalyzer::getActions(bool, bool, DB::CompileExpressions) @ 0x0000000014538609 15. /build/src/Storages/StorageDistributed.cpp:266: DB::(anonymous namespace)::buildShardingKeyExpression(std::shared_ptr const&, std::shared_ptr, DB::NamesAndTypesList const&, bool) @ 0x0000000015d5e6aa 16. /build/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) @ 0x0000000015d5cf4d 17. /build/contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: std::shared_ptr std::allocate_shared[abi:se190107], 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&&) @ 0x0000000011809909 18. /build/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 @ 0x0000000011805a50 19. /build/src/TableFunctions/ITableFunction.cpp:36: DB::ITableFunction::execute(std::shared_ptr const&, std::shared_ptr, String const&, DB::ColumnsDescription, bool, bool) const @ 0x00000000131e9fc3 20. /build/src/Interpreters/Context.cpp:2501: DB::Context::executeTableFunction(std::shared_ptr const&, std::shared_ptr const&) @ 0x00000000144345b2 21. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:4975: DB::QueryAnalyzer::resolveTableFunction(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&, bool) @ 0x000000001401e9f9 22. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5342: DB::QueryAnalyzer::resolveQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&) @ 0x00000000140452bf 23. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5597: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000140136f0 24. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000140127f9 25. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000014011fce 26. /build/src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000001406ce8a 27. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000014973b42 28. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000001497268d 29. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000014974d24 30. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001492924b 31. /build/src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88641 2025.07.28 11:52:14.954466 [ 17256 ] {f3a13a09-8ccf-40f7-ada4-cbf386765acb} executeQuery: Code: 60. DB::Exception: Table default.id does not exist: While processing 1 IN (id). (UNKNOWN_TABLE) (version 25.3.6.10636.altinitytest (altinity build)) (from [::1]:58170) (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. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000a06a8eb 4. /build/src/Databases/IDatabase.cpp:41: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x0000000013dd565f 5. /build/src/Interpreters/DatabaseCatalog.cpp:442: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x00000000144f0869 6. /build/src/Interpreters/DatabaseCatalog.cpp:976: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x00000000144f6c88 7. /build/src/Interpreters/interpretSubquery.cpp:108: DB::interpretSubquery(std::shared_ptr const&, std::shared_ptr, std::vector> const&, DB::SelectQueryOptions const&) @ 0x0000000014ca52d7 8. /build/src/Interpreters/interpretSubquery.cpp:37: DB::interpretSubquery(std::shared_ptr const&, std::shared_ptr, unsigned long, std::vector> const&) @ 0x0000000014ca49c5 9. /build/src/Interpreters/ActionsVisitor.cpp:1516: DB::ActionsMatcher::makeSet(DB::ASTFunction const&, DB::ActionsMatcher::Data&, bool) @ 0x000000001455d045 10. /build/src/Interpreters/ActionsVisitor.cpp:999: DB::ActionsMatcher::visit(DB::ASTFunction const&, std::shared_ptr const&, DB::ActionsMatcher::Data&) @ 0x0000000014554175 11. /build/src/Interpreters/InDepthNodeVisitor.h:71: DB::InDepthNodeVisitor const>::doVisit(std::shared_ptr const&) @ 0x000000001454b195 12. /build/src/Interpreters/InDepthNodeVisitor.h:61: DB::ExpressionAnalyzer::getRootActions(std::shared_ptr const&, bool, DB::ActionsDAG&, bool) @ 0x0000000014528f28 13. /build/src/Interpreters/ExpressionAnalyzer.cpp:1867: DB::ExpressionAnalyzer::getActionsDAG(bool, bool) @ 0x00000000145381d6 14. /build/src/Interpreters/ExpressionAnalyzer.cpp:1902: DB::ExpressionAnalyzer::getActions(bool, bool, DB::CompileExpressions) @ 0x0000000014538609 15. /build/src/Storages/StorageDistributed.cpp:266: DB::(anonymous namespace)::buildShardingKeyExpression(std::shared_ptr const&, std::shared_ptr, DB::NamesAndTypesList const&, bool) @ 0x0000000015d5e6aa 16. /build/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) @ 0x0000000015d5cf4d 17. /build/contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: std::shared_ptr std::allocate_shared[abi:se190107], 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&&) @ 0x0000000011809909 18. /build/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 @ 0x0000000011805a50 19. /build/src/TableFunctions/ITableFunction.cpp:36: DB::ITableFunction::execute(std::shared_ptr const&, std::shared_ptr, String const&, DB::ColumnsDescription, bool, bool) const @ 0x00000000131e9fc3 20. /build/src/Interpreters/Context.cpp:2501: DB::Context::executeTableFunction(std::shared_ptr const&, std::shared_ptr const&) @ 0x00000000144345b2 21. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:4975: DB::QueryAnalyzer::resolveTableFunction(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&, bool) @ 0x000000001401e9f9 22. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5342: DB::QueryAnalyzer::resolveQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&) @ 0x00000000140452bf 23. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5597: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000140136f0 24. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000140127f9 25. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000014011fce 26. /build/src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000001406ce8a 27. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000014973b42 28. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000001497268d 29. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000014974d24 30. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001492924b 31. /build/src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88641 2025.07.28 11:52:14.979220 [ 17256 ] {} 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. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000a06a8eb 4. /build/src/Databases/IDatabase.cpp:41: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x0000000013dd565f 5. /build/src/Interpreters/DatabaseCatalog.cpp:442: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x00000000144f0869 6. /build/src/Interpreters/DatabaseCatalog.cpp:976: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x00000000144f6c88 7. /build/src/Interpreters/interpretSubquery.cpp:108: DB::interpretSubquery(std::shared_ptr const&, std::shared_ptr, std::vector> const&, DB::SelectQueryOptions const&) @ 0x0000000014ca52d7 8. /build/src/Interpreters/interpretSubquery.cpp:37: DB::interpretSubquery(std::shared_ptr const&, std::shared_ptr, unsigned long, std::vector> const&) @ 0x0000000014ca49c5 9. /build/src/Interpreters/ActionsVisitor.cpp:1516: DB::ActionsMatcher::makeSet(DB::ASTFunction const&, DB::ActionsMatcher::Data&, bool) @ 0x000000001455d045 10. /build/src/Interpreters/ActionsVisitor.cpp:999: DB::ActionsMatcher::visit(DB::ASTFunction const&, std::shared_ptr const&, DB::ActionsMatcher::Data&) @ 0x0000000014554175 11. /build/src/Interpreters/InDepthNodeVisitor.h:71: DB::InDepthNodeVisitor const>::doVisit(std::shared_ptr const&) @ 0x000000001454b195 12. /build/src/Interpreters/InDepthNodeVisitor.h:61: DB::ExpressionAnalyzer::getRootActions(std::shared_ptr const&, bool, DB::ActionsDAG&, bool) @ 0x0000000014528f28 13. /build/src/Interpreters/ExpressionAnalyzer.cpp:1867: DB::ExpressionAnalyzer::getActionsDAG(bool, bool) @ 0x00000000145381d6 14. /build/src/Interpreters/ExpressionAnalyzer.cpp:1902: DB::ExpressionAnalyzer::getActions(bool, bool, DB::CompileExpressions) @ 0x0000000014538609 15. /build/src/Storages/StorageDistributed.cpp:266: DB::(anonymous namespace)::buildShardingKeyExpression(std::shared_ptr const&, std::shared_ptr, DB::NamesAndTypesList const&, bool) @ 0x0000000015d5e6aa 16. /build/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) @ 0x0000000015d5cf4d 17. /build/contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: std::shared_ptr std::allocate_shared[abi:se190107], 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&&) @ 0x0000000011809909 18. /build/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 @ 0x0000000011805a50 19. /build/src/TableFunctions/ITableFunction.cpp:36: DB::ITableFunction::execute(std::shared_ptr const&, std::shared_ptr, String const&, DB::ColumnsDescription, bool, bool) const @ 0x00000000131e9fc3 20. /build/src/Interpreters/Context.cpp:2501: DB::Context::executeTableFunction(std::shared_ptr const&, std::shared_ptr const&) @ 0x00000000144345b2 21. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:4975: DB::QueryAnalyzer::resolveTableFunction(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&, bool) @ 0x000000001401e9f9 22. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5342: DB::QueryAnalyzer::resolveQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&) @ 0x00000000140452bf 23. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5597: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000140136f0 24. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000140127f9 25. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000014011fce 26. /build/src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000001406ce8a 27. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000014973b42 28. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000001497268d 29. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000014974d24 30. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001492924b 31. /build/src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88641 2025.07.28 11:52:15.208636 [ 17256 ] {1146f0ae-7d9f-4537-9ce9-46356143786d} executeQuery: Code: 60. DB::Exception: Table default.id does not exist: While processing 1 IN (id). (UNKNOWN_TABLE) (version 25.3.6.10636.altinitytest (altinity build)) (from [::1]:58170) (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. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000a06a8eb 4. /build/src/Databases/IDatabase.cpp:41: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x0000000013dd565f 5. /build/src/Interpreters/DatabaseCatalog.cpp:442: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x00000000144f0869 6. /build/src/Interpreters/DatabaseCatalog.cpp:976: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x00000000144f6c88 7. /build/src/Interpreters/interpretSubquery.cpp:108: DB::interpretSubquery(std::shared_ptr const&, std::shared_ptr, std::vector> const&, DB::SelectQueryOptions const&) @ 0x0000000014ca52d7 8. /build/src/Interpreters/interpretSubquery.cpp:37: DB::interpretSubquery(std::shared_ptr const&, std::shared_ptr, unsigned long, std::vector> const&) @ 0x0000000014ca49c5 9. /build/src/Interpreters/ActionsVisitor.cpp:1516: DB::ActionsMatcher::makeSet(DB::ASTFunction const&, DB::ActionsMatcher::Data&, bool) @ 0x000000001455d045 10. /build/src/Interpreters/ActionsVisitor.cpp:999: DB::ActionsMatcher::visit(DB::ASTFunction const&, std::shared_ptr const&, DB::ActionsMatcher::Data&) @ 0x0000000014554175 11. /build/src/Interpreters/InDepthNodeVisitor.h:71: DB::InDepthNodeVisitor const>::doVisit(std::shared_ptr const&) @ 0x000000001454b195 12. /build/src/Interpreters/InDepthNodeVisitor.h:61: DB::ExpressionAnalyzer::getRootActions(std::shared_ptr const&, bool, DB::ActionsDAG&, bool) @ 0x0000000014528f28 13. /build/src/Interpreters/ExpressionAnalyzer.cpp:1867: DB::ExpressionAnalyzer::getActionsDAG(bool, bool) @ 0x00000000145381d6 14. /build/src/Interpreters/ExpressionAnalyzer.cpp:1902: DB::ExpressionAnalyzer::getActions(bool, bool, DB::CompileExpressions) @ 0x0000000014538609 15. /build/src/Storages/StorageDistributed.cpp:266: DB::(anonymous namespace)::buildShardingKeyExpression(std::shared_ptr const&, std::shared_ptr, DB::NamesAndTypesList const&, bool) @ 0x0000000015d5e6aa 16. /build/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) @ 0x0000000015d5cf4d 17. /build/contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: std::shared_ptr std::allocate_shared[abi:se190107], 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&&) @ 0x0000000011809909 18. /build/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 @ 0x0000000011805a50 19. /build/src/TableFunctions/ITableFunction.cpp:36: DB::ITableFunction::execute(std::shared_ptr const&, std::shared_ptr, String const&, DB::ColumnsDescription, bool, bool) const @ 0x00000000131e9fc3 20. /build/src/Interpreters/Context.cpp:2501: DB::Context::executeTableFunction(std::shared_ptr const&, std::shared_ptr const&) @ 0x00000000144345b2 21. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:4975: DB::QueryAnalyzer::resolveTableFunction(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&, bool) @ 0x000000001401e9f9 22. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5342: DB::QueryAnalyzer::resolveQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&) @ 0x00000000140452bf 23. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5597: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000140136f0 24. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000140127f9 25. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000014011fce 26. /build/src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000001406ce8a 27. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000014973b42 28. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000001497268d 29. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000014974d24 30. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001492924b 31. /build/src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88641 2025.07.28 11:52:15.215903 [ 17256 ] {} 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. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000a06a8eb 4. /build/src/Databases/IDatabase.cpp:41: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x0000000013dd565f 5. /build/src/Interpreters/DatabaseCatalog.cpp:442: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x00000000144f0869 6. /build/src/Interpreters/DatabaseCatalog.cpp:976: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x00000000144f6c88 7. /build/src/Interpreters/interpretSubquery.cpp:108: DB::interpretSubquery(std::shared_ptr const&, std::shared_ptr, std::vector> const&, DB::SelectQueryOptions const&) @ 0x0000000014ca52d7 8. /build/src/Interpreters/interpretSubquery.cpp:37: DB::interpretSubquery(std::shared_ptr const&, std::shared_ptr, unsigned long, std::vector> const&) @ 0x0000000014ca49c5 9. /build/src/Interpreters/ActionsVisitor.cpp:1516: DB::ActionsMatcher::makeSet(DB::ASTFunction const&, DB::ActionsMatcher::Data&, bool) @ 0x000000001455d045 10. /build/src/Interpreters/ActionsVisitor.cpp:999: DB::ActionsMatcher::visit(DB::ASTFunction const&, std::shared_ptr const&, DB::ActionsMatcher::Data&) @ 0x0000000014554175 11. /build/src/Interpreters/InDepthNodeVisitor.h:71: DB::InDepthNodeVisitor const>::doVisit(std::shared_ptr const&) @ 0x000000001454b195 12. /build/src/Interpreters/InDepthNodeVisitor.h:61: DB::ExpressionAnalyzer::getRootActions(std::shared_ptr const&, bool, DB::ActionsDAG&, bool) @ 0x0000000014528f28 13. /build/src/Interpreters/ExpressionAnalyzer.cpp:1867: DB::ExpressionAnalyzer::getActionsDAG(bool, bool) @ 0x00000000145381d6 14. /build/src/Interpreters/ExpressionAnalyzer.cpp:1902: DB::ExpressionAnalyzer::getActions(bool, bool, DB::CompileExpressions) @ 0x0000000014538609 15. /build/src/Storages/StorageDistributed.cpp:266: DB::(anonymous namespace)::buildShardingKeyExpression(std::shared_ptr const&, std::shared_ptr, DB::NamesAndTypesList const&, bool) @ 0x0000000015d5e6aa 16. /build/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) @ 0x0000000015d5cf4d 17. /build/contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: std::shared_ptr std::allocate_shared[abi:se190107], 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&&) @ 0x0000000011809909 18. /build/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 @ 0x0000000011805a50 19. /build/src/TableFunctions/ITableFunction.cpp:36: DB::ITableFunction::execute(std::shared_ptr const&, std::shared_ptr, String const&, DB::ColumnsDescription, bool, bool) const @ 0x00000000131e9fc3 20. /build/src/Interpreters/Context.cpp:2501: DB::Context::executeTableFunction(std::shared_ptr const&, std::shared_ptr const&) @ 0x00000000144345b2 21. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:4975: DB::QueryAnalyzer::resolveTableFunction(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&, bool) @ 0x000000001401e9f9 22. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5342: DB::QueryAnalyzer::resolveQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&) @ 0x00000000140452bf 23. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5597: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000140136f0 24. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000140127f9 25. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000014011fce 26. /build/src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000001406ce8a 27. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000014973b42 28. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000001497268d 29. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000014974d24 30. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001492924b 31. /build/src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88641 2025.07.28 11:52:15.298766 [ 3966 ] {} test_13.rmt2 (7f9b740d-015c-470e-8cc6-8ba33be0dc63): auto DB::StorageReplicatedMergeTree::processQueueEntry(ReplicatedMergeTreeQueue::SelectedEntryPtr)::(anonymous class)::operator()(LogEntryPtr &) const: Code: 86. DB::HTTPException: Received error from remote server http://146b4357c08d:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Ftest%2F01165%2Ftest_13%2Frmt%2Freplicas%2F1&part=20250728_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.6.10636.altinitytest (altinity build)) '. (RECEIVED_ERROR_FROM_REMOTE_IO_SERVER), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.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 const&, int&&, String const&, unsigned long&&, String const&) @ 0x000000000feda8d9 4. /build/src/IO/HTTPCommon.cpp:104: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x000000000feda6e2 5. /build/src/IO/HTTPCommon.cpp:93: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x000000000feda537 6. /build/src/IO/ReadWriteBufferFromHTTP.cpp:277: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x000000001184a4c4 7. /build/src/IO/ReadWriteBufferFromHTTP.cpp:285: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x000000001184a615 8. /build/src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x000000001184ae59 9. /build/src/IO/ReadWriteBufferFromHTTP.cpp:472: void std::__function::__policy_invoker::__call_impl[abi:se190107]>(std::__function::__policy_storage const*) @ 0x000000001184cedd 10. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001184858b 11. /build/src/IO/ReadWriteBufferFromHTTP.cpp:465: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x000000001184bf0b 12. /build/src/IO/ReadBuffer.h:60: DB::ReadBuffer::next() @ 0x000000000a148c7b 13. /build/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) @ 0x0000000011849fb2 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]>&)>&, 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&) @ 0x0000000011841980 15. /build/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) @ 0x000000001621208e 16. /build/src/Storages/StorageReplicatedMergeTree.cpp:5228: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl[abi:se190107] const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000015f9a5fe 17. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000015ed8bfd 18. /build/src/Storages/StorageReplicatedMergeTree.cpp:2514: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x0000000015ec9aab 19. /build/src/Storages/StorageReplicatedMergeTree.cpp:2349: DB::StorageReplicatedMergeTree::executeLogEntry(DB::ReplicatedMergeTreeLogEntry&) @ 0x0000000015eba91b 20. /build/src/Storages/StorageReplicatedMergeTree.cpp:3876: bool std::__function::__policy_invoker&)>::__call_impl[abi:se190107])::$_1, bool (std::shared_ptr&)>>(std::__function::__policy_storage const*, std::shared_ptr&) @ 0x0000000015f9837e 21. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000165d6fc3 22. /build/src/Storages/StorageReplicatedMergeTree.cpp:3872: DB::StorageReplicatedMergeTree::processQueueEntry(std::shared_ptr) @ 0x0000000015efc18a 23. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001624c1b2 24. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000162f9c70 25. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x00000000162fa55a 26. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc6653 27. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000000fccc4c3 28. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc3d92 29. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fcca080 30. ? @ 0x00007fbc6213eac3 31. ? @ 0x00007fbc621d0850 (version 25.3.6.10636.altinitytest (altinity build)) 2025.07.28 11:52:15.983803 [ 3936 ] {} MergeTreeBackgroundExecutor: Exception while executing background task {7c071e3e-bee6-456f-a3ed-b1fb8e312665::202507_1_46_9}: 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. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, char const*&&, char const*&&) @ 0x000000000fc1a8eb 4. /build/src/Common/MemoryTracker.cpp:196: MemoryTracker::injectFault() const @ 0x000000000fc18390 5. /build/src/Storages/MergeTree/MergePlainMergeTreeTask.cpp:153: DB::MergePlainMergeTreeTask::finish() @ 0x000000001666f399 6. /build/src/Storages/MergeTree/MergePlainMergeTreeTask.cpp:72: DB::MergePlainMergeTreeTask::executeStep() @ 0x000000001666e852 7. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000162fc850 8. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x00000000162fd193 9. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc6653 10. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000000fccc4c3 11. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc3d92 12. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fcca080 13. ? @ 0x00007fbc6213eac3 14. ? @ 0x00007fbc621d0850 (version 25.3.6.10636.altinitytest (altinity build)) 2025.07.28 11:52:16.351270 [ 3283 ] {b349622a-0a8c-4ed4-8546-1105425ebe00} executeQuery: Code: 469. DB::Exception: Constraint `cs_value2` for table test_1.table_for_rename (505ee15b-e6b5-4ada-aaa4-e65b597c844f) is violated at row 1. Expression: (toInt64(value2) < toInt64(value3)). Column values: value2 = '1', value3 = '0'. (VIOLATED_CONSTRAINT) (version 25.3.6.10636.altinitytest (altinity build)) (from [::1]:58144) (comment: 01277_alter_rename_column_constraint.sql) (query 4, line 18) (in query: INSERT INTO table_for_rename SELECT toDate('2019-10-01') + number % 3, number, toString(number), toString(number + 1), toString(number) from numbers(9);), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.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&) @ 0x0000000013cd2239 4. /build/src/Processors/Transforms/CheckConstraintsTransform.cpp:119: DB::CheckConstraintsTransform::onConsume(DB::Chunk) @ 0x0000000016bfc0bc 5. /build/src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: void std::__function::__policy_invoker::__call_impl[abi:se190107]>(std::__function::__policy_storage const*) @ 0x0000000016c0ad89 6. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000016c0abf5 7. /build/src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: DB::ExceptionKeepingTransform::work() @ 0x0000000016c0a6fe 8. /build/src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x00000000169bd00f 9. /build/src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x00000000169b2105 10. /build/src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeSingleThread(unsigned long) @ 0x00000000169b23be 11. /build/src/Processors/Executors/PipelineExecutor.cpp:454: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x00000000169b0be7 12. /build/src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x00000000169b03f4 13. /build/src/Processors/Executors/CompletedPipelineExecutor.cpp:42: void std::__function::__policy_invoker::__call_impl[abi:se190107]::ThreadFromGlobalPoolImpl(DB::CompletedPipelineExecutor::execute()::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169af7e1 14. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc3d92 15. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fcca080 16. ? @ 0x00007fbc6213eac3 17. ? @ 0x00007fbc621d0850 2025.07.28 11:52:16.436550 [ 3961 ] {} test_13.rmt2 (7f9b740d-015c-470e-8cc6-8ba33be0dc63): auto DB::StorageReplicatedMergeTree::processQueueEntry(ReplicatedMergeTreeQueue::SelectedEntryPtr)::(anonymous class)::operator()(LogEntryPtr &) const: Code: 86. DB::HTTPException: Received error from remote server http://146b4357c08d:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Ftest%2F01165%2Ftest_13%2Frmt%2Freplicas%2F1&part=20250728_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.6.10636.altinitytest (altinity build)) '. (RECEIVED_ERROR_FROM_REMOTE_IO_SERVER), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.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 const&, int&&, String const&, unsigned long&&, String const&) @ 0x000000000feda8d9 4. /build/src/IO/HTTPCommon.cpp:104: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x000000000feda6e2 5. /build/src/IO/HTTPCommon.cpp:93: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x000000000feda537 6. /build/src/IO/ReadWriteBufferFromHTTP.cpp:277: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x000000001184a4c4 7. /build/src/IO/ReadWriteBufferFromHTTP.cpp:285: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x000000001184a615 8. /build/src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x000000001184ae59 9. /build/src/IO/ReadWriteBufferFromHTTP.cpp:472: void std::__function::__policy_invoker::__call_impl[abi:se190107]>(std::__function::__policy_storage const*) @ 0x000000001184cedd 10. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001184858b 11. /build/src/IO/ReadWriteBufferFromHTTP.cpp:465: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x000000001184bf0b 12. /build/src/IO/ReadBuffer.h:60: DB::ReadBuffer::next() @ 0x000000000a148c7b 13. /build/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) @ 0x0000000011849fb2 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]>&)>&, 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&) @ 0x0000000011841980 15. /build/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) @ 0x000000001621208e 16. /build/src/Storages/StorageReplicatedMergeTree.cpp:5228: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl[abi:se190107] const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000015f9a5fe 17. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000015ed8bfd 18. /build/src/Storages/StorageReplicatedMergeTree.cpp:2514: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x0000000015ec9aab 19. /build/src/Storages/StorageReplicatedMergeTree.cpp:2349: DB::StorageReplicatedMergeTree::executeLogEntry(DB::ReplicatedMergeTreeLogEntry&) @ 0x0000000015eba91b 20. /build/src/Storages/StorageReplicatedMergeTree.cpp:3876: bool std::__function::__policy_invoker&)>::__call_impl[abi:se190107])::$_1, bool (std::shared_ptr&)>>(std::__function::__policy_storage const*, std::shared_ptr&) @ 0x0000000015f9837e 21. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000165d6fc3 22. /build/src/Storages/StorageReplicatedMergeTree.cpp:3872: DB::StorageReplicatedMergeTree::processQueueEntry(std::shared_ptr) @ 0x0000000015efc18a 23. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001624c1b2 24. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000162f9c70 25. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x00000000162fa55a 26. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc6653 27. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000000fccc4c3 28. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc3d92 29. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fcca080 30. ? @ 0x00007fbc6213eac3 31. ? @ 0x00007fbc621d0850 (version 25.3.6.10636.altinitytest (altinity build)) 2025.07.28 11:52:16.460347 [ 3283 ] {} TCPHandler: Code: 469. DB::Exception: Constraint `cs_value2` for table test_1.table_for_rename (505ee15b-e6b5-4ada-aaa4-e65b597c844f) is violated at row 1. Expression: (toInt64(value2) < toInt64(value3)). Column values: value2 = '1', value3 = '0'. (VIOLATED_CONSTRAINT), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.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&) @ 0x0000000013cd2239 4. /build/src/Processors/Transforms/CheckConstraintsTransform.cpp:119: DB::CheckConstraintsTransform::onConsume(DB::Chunk) @ 0x0000000016bfc0bc 5. /build/src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: void std::__function::__policy_invoker::__call_impl[abi:se190107]>(std::__function::__policy_storage const*) @ 0x0000000016c0ad89 6. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000016c0abf5 7. /build/src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: DB::ExceptionKeepingTransform::work() @ 0x0000000016c0a6fe 8. /build/src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x00000000169bd00f 9. /build/src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x00000000169b2105 10. /build/src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeSingleThread(unsigned long) @ 0x00000000169b23be 11. /build/src/Processors/Executors/PipelineExecutor.cpp:454: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x00000000169b0be7 12. /build/src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x00000000169b03f4 13. /build/src/Processors/Executors/CompletedPipelineExecutor.cpp:42: void std::__function::__policy_invoker::__call_impl[abi:se190107]::ThreadFromGlobalPoolImpl(DB::CompletedPipelineExecutor::execute()::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169af7e1 14. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc3d92 15. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fcca080 16. ? @ 0x00007fbc6213eac3 17. ? @ 0x00007fbc621d0850 Job's origin stack trace: 0. /build/src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000000fc33b84 1. /build/src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000000fcc2ea7 2. /build/src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fcc535c 3. /build/src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000000fcc584d 4. /build/src/Common/ThreadPool.h:279: DB::CompletedPipelineExecutor::execute() @ 0x00000000169af267 5. /build/src/Server/TCPHandler.cpp:707: DB::TCPHandler::runImpl() @ 0x00000000168e6b2e 6. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 7. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 8. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 9. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 10. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 11. ? @ 0x00007fbc6213eac3 12. ? @ 0x00007fbc621d0850 2025.07.28 11:52:16.544064 [ 5747 ] {1cabb8c2-d138-4281-a476-ca425ae6dde8} executeQuery: Code: 48. DB::Exception: Method getDataAt is not supported for Array(LowCardinality(String)): While executing RawBLOBRowOutputFormat. (NOT_IMPLEMENTED) (version 25.3.6.10636.altinitytest (altinity build)) (from [::ffff:127.0.0.1]:53582) (comment: 02429_low_cardinality_trash.sh) (in query: SELECT rand64(1) % 10 AS k, groupArray(toString(64 - floor(log2(rand64(2) + 1))))::Array(LowCardinality(String)) FROM numbers(100) GROUP BY k FORMAT RawBLOB), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x000000000a06b56b 4. /build/src/Columns/ColumnArray.cpp:185: DB::ColumnArray::getDataAt(unsigned long) const @ 0x00000000158e0738 5. /build/src/Processors/Formats/Impl/RawBLOBRowOutputFormat.cpp:23: DB::RawBLOBRowOutputFormat::writeField(DB::IColumn const&, DB::ISerialization const&, unsigned long) @ 0x0000000016bb35fd 6. /build/src/Processors/Formats/IRowOutputFormat.cpp:78: DB::IRowOutputFormat::write(std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, unsigned long) @ 0x00000000169c91a4 7. /build/src/Processors/Formats/IRowOutputFormat.cpp:31: DB::IRowOutputFormat::consume(DB::Chunk) @ 0x00000000169c8f0c 8. /build/src/Processors/Formats/IOutputFormat.cpp:98: DB::IOutputFormat::work() @ 0x00000000169c76ee 9. /build/src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x00000000169bd00f 10. /build/src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x00000000169b2105 11. /build/src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeSingleThread(unsigned long) @ 0x00000000169b23be 12. /build/src/Processors/Executors/PipelineExecutor.cpp:416: void std::__function::__policy_invoker::__call_impl[abi:se190107]>(std::__function::__policy_storage const*) @ 0x00000000169b2e3f 13. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc6653 14. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000000fccc4c3 15. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc3d92 16. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fcca080 17. ? @ 0x00007fbc6213eac3 18. ? @ 0x00007fbc621d0850 2025.07.28 11:52:16.569034 [ 3965 ] {} test_13.alter_table1 (b6d50f9f-3cd1-4fee-aa3e-84cf679f8083): Part /var/lib/clickhouse/store/b6d/b6d50f9f-3cd1-4fee-aa3e-84cf679f8083/detached/all_8_8_0/ is broken and needs manual correction. Reason: Code: 226. DB::Exception: No columns.txt in part all_24_24_0, expected path store/b6d/b6d50f9f-3cd1-4fee-aa3e-84cf679f8083/detached/all_8_8_0/columns.txt on drive default. (NO_FILE_IN_DATA_PART), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, String&, String&&) @ 0x0000000012da2e0b 4. /build/src/Storages/MergeTree/IMergeTreeDataPart.cpp:1629: DB::IMergeTreeDataPart::loadColumns(bool) @ 0x000000001625bb62 5. /build/src/Storages/MergeTree/IMergeTreeDataPart.cpp:839: DB::IMergeTreeDataPart::loadColumnsChecksumsIndexes(bool, bool) @ 0x0000000016259f5b 6. /build/src/Storages/StorageReplicatedMergeTree.cpp:2237: DB::StorageReplicatedMergeTree::attachPartHelperFoundValidPart(DB::ReplicatedMergeTreeLogEntry const&) const @ 0x0000000015eb838f 7. /build/src/Storages/StorageReplicatedMergeTree.cpp:2309: DB::StorageReplicatedMergeTree::executeLogEntry(DB::ReplicatedMergeTreeLogEntry&) @ 0x0000000015eb969e 8. /build/src/Storages/StorageReplicatedMergeTree.cpp:3876: bool std::__function::__policy_invoker&)>::__call_impl[abi:se190107])::$_1, bool (std::shared_ptr&)>>(std::__function::__policy_storage const*, std::shared_ptr&) @ 0x0000000015f9837e 9. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000165d6fc3 10. /build/src/Storages/StorageReplicatedMergeTree.cpp:3872: DB::StorageReplicatedMergeTree::processQueueEntry(std::shared_ptr) @ 0x0000000015efc18a 11. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001624c1b2 12. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000162f9c70 13. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x00000000162fa55a 14. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc6653 15. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000000fccc4c3 16. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc3d92 17. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fcca080 18. ? @ 0x00007fbc6213eac3 19. ? @ 0x00007fbc621d0850 (version 25.3.6.10636.altinitytest (altinity build)) 2025.07.28 11:52:16.570292 [ 3283 ] {37564082-2508-46db-a8ed-01184939f48a} executeQuery: Code: 47. DB::Exception: Unknown expression or function identifier `x` in scope x = 1. (UNKNOWN_IDENTIFIER) (version 25.3.6.10636.altinitytest (altinity build)) (from [::1]:58144) (comment: 01277_alter_rename_column_constraint.sql) (query 5, line 20) (in query: SELECT * FROM table_for_rename ORDER BY key;), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.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&&) @ 0x000000001404b3b9 4. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3771: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000001401b849 5. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3980: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000014018e31 6. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:2925: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000001402fcbd 7. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3838: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000014019a9e 8. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:209: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000001401270e 9. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000014011fce 10. /build/src/Planner/Utils.cpp:458: DB::buildFilterInfo(std::shared_ptr, std::shared_ptr const&, std::shared_ptr&, std::unordered_set, std::equal_to, std::allocator>) @ 0x0000000013fe8bcf 11. /build/src/Planner/PlannerJoinTree.cpp:535: DB::(anonymous namespace)::buildQueryPlanForTableExpression(std::shared_ptr, std::shared_ptr const&, DB::SelectQueryInfo const&, DB::SelectQueryOptions const&, std::shared_ptr&, bool, bool) @ 0x00000000149956d3 12. /build/src/Planner/PlannerJoinTree.cpp:2252: DB::buildJoinTreeQueryPlan(std::shared_ptr const&, DB::SelectQueryInfo const&, DB::SelectQueryOptions&, std::unordered_set, std::equal_to, std::allocator> const&, std::shared_ptr&) @ 0x000000001498e109 13. /build/src/Planner/Planner.cpp:1553: DB::Planner::buildPlanForQueryNode() @ 0x0000000014979dae 14. /build/src/Planner/Planner.cpp:1308: DB::Planner::buildQueryPlanIfNeeded() @ 0x000000001497685c 15. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:255: DB::InterpreterSelectQueryAnalyzer::getQueryPlan() @ 0x000000001497476d 16. /build/src/Interpreters/executeQuery.cpp:1405: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88806 17. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 18. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 19. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 20. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 21. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 22. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 23. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 24. ? @ 0x00007fbc6213eac3 25. ? @ 0x00007fbc621d0850 2025.07.28 11:52:16.587027 [ 3283 ] {} TCPHandler: Code: 47. DB::Exception: Unknown expression or function identifier `x` in scope x = 1. (UNKNOWN_IDENTIFIER), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.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&&) @ 0x000000001404b3b9 4. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3771: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000001401b849 5. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3980: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000014018e31 6. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:2925: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000001402fcbd 7. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3838: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000014019a9e 8. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:209: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000001401270e 9. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000014011fce 10. /build/src/Planner/Utils.cpp:458: DB::buildFilterInfo(std::shared_ptr, std::shared_ptr const&, std::shared_ptr&, std::unordered_set, std::equal_to, std::allocator>) @ 0x0000000013fe8bcf 11. /build/src/Planner/PlannerJoinTree.cpp:535: DB::(anonymous namespace)::buildQueryPlanForTableExpression(std::shared_ptr, std::shared_ptr const&, DB::SelectQueryInfo const&, DB::SelectQueryOptions const&, std::shared_ptr&, bool, bool) @ 0x00000000149956d3 12. /build/src/Planner/PlannerJoinTree.cpp:2252: DB::buildJoinTreeQueryPlan(std::shared_ptr const&, DB::SelectQueryInfo const&, DB::SelectQueryOptions&, std::unordered_set, std::equal_to, std::allocator> const&, std::shared_ptr&) @ 0x000000001498e109 13. /build/src/Planner/Planner.cpp:1553: DB::Planner::buildPlanForQueryNode() @ 0x0000000014979dae 14. /build/src/Planner/Planner.cpp:1308: DB::Planner::buildQueryPlanIfNeeded() @ 0x000000001497685c 15. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:255: DB::InterpreterSelectQueryAnalyzer::getQueryPlan() @ 0x000000001497476d 16. /build/src/Interpreters/executeQuery.cpp:1405: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88806 17. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 18. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 19. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 20. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 21. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 22. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 23. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 24. ? @ 0x00007fbc6213eac3 25. ? @ 0x00007fbc621d0850 2025.07.28 11:52:16.596795 [ 5747 ] {1cabb8c2-d138-4281-a476-ca425ae6dde8} DynamicQueryHandler: Code: 48. DB::Exception: Method getDataAt is not supported for Array(LowCardinality(String)): While executing RawBLOBRowOutputFormat. (NOT_IMPLEMENTED), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x000000000a06b56b 4. /build/src/Columns/ColumnArray.cpp:185: DB::ColumnArray::getDataAt(unsigned long) const @ 0x00000000158e0738 5. /build/src/Processors/Formats/Impl/RawBLOBRowOutputFormat.cpp:23: DB::RawBLOBRowOutputFormat::writeField(DB::IColumn const&, DB::ISerialization const&, unsigned long) @ 0x0000000016bb35fd 6. /build/src/Processors/Formats/IRowOutputFormat.cpp:78: DB::IRowOutputFormat::write(std::vector::immutable_ptr, std::allocator::immutable_ptr>> const&, unsigned long) @ 0x00000000169c91a4 7. /build/src/Processors/Formats/IRowOutputFormat.cpp:31: DB::IRowOutputFormat::consume(DB::Chunk) @ 0x00000000169c8f0c 8. /build/src/Processors/Formats/IOutputFormat.cpp:98: DB::IOutputFormat::work() @ 0x00000000169c76ee 9. /build/src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x00000000169bd00f 10. /build/src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x00000000169b2105 11. /build/src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeSingleThread(unsigned long) @ 0x00000000169b23be 12. /build/src/Processors/Executors/PipelineExecutor.cpp:416: void std::__function::__policy_invoker::__call_impl[abi:se190107]>(std::__function::__policy_storage const*) @ 0x00000000169b2e3f 13. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc6653 14. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000000fccc4c3 15. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc3d92 16. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fcca080 17. ? @ 0x00007fbc6213eac3 18. ? @ 0x00007fbc621d0850 Job's origin stack trace: 0. /build/src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000000fc33b84 1. /build/src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000000fcc2ea7 2. /build/src/Common/ThreadPool.cpp:401: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fcc7f1c 3. /build/src/Common/ThreadPool.cpp:494: ThreadPoolImpl>::scheduleOrThrowOnError(std::function, Priority) @ 0x000000000fcc7a0e 4. /build/src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::spawnThreadsImpl() @ 0x00000000169b2c0c 5. /build/src/Processors/Executors/PipelineExecutor.cpp:394: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x00000000169b0ba7 6. /build/src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x00000000169b03f4 7. /build/src/Processors/Executors/CompletedPipelineExecutor.cpp:105: DB::CompletedPipelineExecutor::execute() @ 0x00000000169af3c4 8. /build/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&)>) @ 0x0000000014c8d123 9. /build/src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000001686da12 10. /build/src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x0000000016870807 11. /build/src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x0000000016907e99 12. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 13. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 14. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 15. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 16. ? @ 0x00007fbc6213eac3 17. ? @ 0x00007fbc621d0850 (version 25.3.6.10636.altinitytest (altinity build)) 2025.07.28 11:52:17.340159 [ 3977 ] {} test_13.rmt2 (7f9b740d-015c-470e-8cc6-8ba33be0dc63): auto DB::StorageReplicatedMergeTree::processQueueEntry(ReplicatedMergeTreeQueue::SelectedEntryPtr)::(anonymous class)::operator()(LogEntryPtr &) const: Code: 86. DB::HTTPException: Received error from remote server http://146b4357c08d:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Ftest%2F01165%2Ftest_13%2Frmt%2Freplicas%2F1&part=20250728_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.6.10636.altinitytest (altinity build)) '. (RECEIVED_ERROR_FROM_REMOTE_IO_SERVER), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.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 const&, int&&, String const&, unsigned long&&, String const&) @ 0x000000000feda8d9 4. /build/src/IO/HTTPCommon.cpp:104: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x000000000feda6e2 5. /build/src/IO/HTTPCommon.cpp:93: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x000000000feda537 6. /build/src/IO/ReadWriteBufferFromHTTP.cpp:277: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x000000001184a4c4 7. /build/src/IO/ReadWriteBufferFromHTTP.cpp:285: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x000000001184a615 8. /build/src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x000000001184ae59 9. /build/src/IO/ReadWriteBufferFromHTTP.cpp:472: void std::__function::__policy_invoker::__call_impl[abi:se190107]>(std::__function::__policy_storage const*) @ 0x000000001184cedd 10. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001184858b 11. /build/src/IO/ReadWriteBufferFromHTTP.cpp:465: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x000000001184bf0b 12. /build/src/IO/ReadBuffer.h:60: DB::ReadBuffer::next() @ 0x000000000a148c7b 13. /build/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) @ 0x0000000011849fb2 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]>&)>&, 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&) @ 0x0000000011841980 15. /build/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) @ 0x000000001621208e 16. /build/src/Storages/StorageReplicatedMergeTree.cpp:5228: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl[abi:se190107] const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000015f9a5fe 17. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000015ed8bfd 18. /build/src/Storages/StorageReplicatedMergeTree.cpp:2514: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x0000000015ec9aab 19. /build/src/Storages/StorageReplicatedMergeTree.cpp:2349: DB::StorageReplicatedMergeTree::executeLogEntry(DB::ReplicatedMergeTreeLogEntry&) @ 0x0000000015eba91b 20. /build/src/Storages/StorageReplicatedMergeTree.cpp:3876: bool std::__function::__policy_invoker&)>::__call_impl[abi:se190107])::$_1, bool (std::shared_ptr&)>>(std::__function::__policy_storage const*, std::shared_ptr&) @ 0x0000000015f9837e 21. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000165d6fc3 22. /build/src/Storages/StorageReplicatedMergeTree.cpp:3872: DB::StorageReplicatedMergeTree::processQueueEntry(std::shared_ptr) @ 0x0000000015efc18a 23. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001624c1b2 24. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000162f9c70 25. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x00000000162fa55a 26. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc6653 27. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000000fccc4c3 28. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc3d92 29. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fcca080 30. ? @ 0x00007fbc6213eac3 31. ? @ 0x00007fbc621d0850 (version 25.3.6.10636.altinitytest (altinity build)) 2025.07.28 11:52:17.375665 [ 3960 ] {} test_13.alter_table1 (b6d50f9f-3cd1-4fee-aa3e-84cf679f8083): Part /var/lib/clickhouse/store/b6d/b6d50f9f-3cd1-4fee-aa3e-84cf679f8083/detached/all_3_3_0/ is broken and needs manual correction. Reason: Code: 226. DB::Exception: No count.txt in part all_26_26_0. (NO_FILE_IN_DATA_PART), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000a9b78ab 4. /build/src/Storages/MergeTree/IMergeTreeDataPart.cpp:1392: DB::IMergeTreeDataPart::loadRowsCount() @ 0x000000001625d57d 5. /build/src/Storages/MergeTree/IMergeTreeDataPart.cpp:851: DB::IMergeTreeDataPart::loadColumnsChecksumsIndexes(bool, bool) @ 0x000000001625a103 6. /build/src/Storages/StorageReplicatedMergeTree.cpp:2237: DB::StorageReplicatedMergeTree::attachPartHelperFoundValidPart(DB::ReplicatedMergeTreeLogEntry const&) const @ 0x0000000015eb838f 7. /build/src/Storages/StorageReplicatedMergeTree.cpp:2309: DB::StorageReplicatedMergeTree::executeLogEntry(DB::ReplicatedMergeTreeLogEntry&) @ 0x0000000015eb969e 8. /build/src/Storages/StorageReplicatedMergeTree.cpp:3876: bool std::__function::__policy_invoker&)>::__call_impl[abi:se190107])::$_1, bool (std::shared_ptr&)>>(std::__function::__policy_storage const*, std::shared_ptr&) @ 0x0000000015f9837e 9. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000165d6fc3 10. /build/src/Storages/StorageReplicatedMergeTree.cpp:3872: DB::StorageReplicatedMergeTree::processQueueEntry(std::shared_ptr) @ 0x0000000015efc18a 11. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001624c1b2 12. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000162f9c70 13. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x00000000162fa55a 14. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc6653 15. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000000fccc4c3 16. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc3d92 17. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fcca080 18. ? @ 0x00007fbc6213eac3 19. ? @ 0x00007fbc621d0850 (version 25.3.6.10636.altinitytest (altinity build)) 2025.07.28 11:52:18.104275 [ 3962 ] {} test_13.rmt2 (7f9b740d-015c-470e-8cc6-8ba33be0dc63): auto DB::StorageReplicatedMergeTree::processQueueEntry(ReplicatedMergeTreeQueue::SelectedEntryPtr)::(anonymous class)::operator()(LogEntryPtr &) const: Code: 86. DB::HTTPException: Received error from remote server http://146b4357c08d:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Ftest%2F01165%2Ftest_13%2Frmt%2Freplicas%2F1&part=20250728_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.6.10636.altinitytest (altinity build)) '. (RECEIVED_ERROR_FROM_REMOTE_IO_SERVER), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.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 const&, int&&, String const&, unsigned long&&, String const&) @ 0x000000000feda8d9 4. /build/src/IO/HTTPCommon.cpp:104: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x000000000feda6e2 5. /build/src/IO/HTTPCommon.cpp:93: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x000000000feda537 6. /build/src/IO/ReadWriteBufferFromHTTP.cpp:277: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x000000001184a4c4 7. /build/src/IO/ReadWriteBufferFromHTTP.cpp:285: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x000000001184a615 8. /build/src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x000000001184ae59 9. /build/src/IO/ReadWriteBufferFromHTTP.cpp:472: void std::__function::__policy_invoker::__call_impl[abi:se190107]>(std::__function::__policy_storage const*) @ 0x000000001184cedd 10. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001184858b 11. /build/src/IO/ReadWriteBufferFromHTTP.cpp:465: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x000000001184bf0b 12. /build/src/IO/ReadBuffer.h:60: DB::ReadBuffer::next() @ 0x000000000a148c7b 13. /build/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) @ 0x0000000011849fb2 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]>&)>&, 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&) @ 0x0000000011841980 15. /build/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) @ 0x000000001621208e 16. /build/src/Storages/StorageReplicatedMergeTree.cpp:5228: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl[abi:se190107] const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000015f9a5fe 17. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000015ed8bfd 18. /build/src/Storages/StorageReplicatedMergeTree.cpp:2514: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x0000000015ec9aab 19. /build/src/Storages/StorageReplicatedMergeTree.cpp:2349: DB::StorageReplicatedMergeTree::executeLogEntry(DB::ReplicatedMergeTreeLogEntry&) @ 0x0000000015eba91b 20. /build/src/Storages/StorageReplicatedMergeTree.cpp:3876: bool std::__function::__policy_invoker&)>::__call_impl[abi:se190107])::$_1, bool (std::shared_ptr&)>>(std::__function::__policy_storage const*, std::shared_ptr&) @ 0x0000000015f9837e 21. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000165d6fc3 22. /build/src/Storages/StorageReplicatedMergeTree.cpp:3872: DB::StorageReplicatedMergeTree::processQueueEntry(std::shared_ptr) @ 0x0000000015efc18a 23. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001624c1b2 24. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000162f9c70 25. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x00000000162fa55a 26. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc6653 27. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000000fccc4c3 28. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc3d92 29. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fcca080 30. ? @ 0x00007fbc6213eac3 31. ? @ 0x00007fbc621d0850 (version 25.3.6.10636.altinitytest (altinity build)) 2025.07.28 11:52:19.189600 [ 3974 ] {} test_13.rmt2 (7f9b740d-015c-470e-8cc6-8ba33be0dc63): auto DB::StorageReplicatedMergeTree::processQueueEntry(ReplicatedMergeTreeQueue::SelectedEntryPtr)::(anonymous class)::operator()(LogEntryPtr &) const: Code: 86. DB::HTTPException: Received error from remote server http://146b4357c08d:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Ftest%2F01165%2Ftest_13%2Frmt%2Freplicas%2F1&part=20250728_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.6.10636.altinitytest (altinity build)) '. (RECEIVED_ERROR_FROM_REMOTE_IO_SERVER), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.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 const&, int&&, String const&, unsigned long&&, String const&) @ 0x000000000feda8d9 4. /build/src/IO/HTTPCommon.cpp:104: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x000000000feda6e2 5. /build/src/IO/HTTPCommon.cpp:93: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x000000000feda537 6. /build/src/IO/ReadWriteBufferFromHTTP.cpp:277: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x000000001184a4c4 7. /build/src/IO/ReadWriteBufferFromHTTP.cpp:285: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x000000001184a615 8. /build/src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x000000001184ae59 9. /build/src/IO/ReadWriteBufferFromHTTP.cpp:472: void std::__function::__policy_invoker::__call_impl[abi:se190107]>(std::__function::__policy_storage const*) @ 0x000000001184cedd 10. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001184858b 11. /build/src/IO/ReadWriteBufferFromHTTP.cpp:465: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x000000001184bf0b 12. /build/src/IO/ReadBuffer.h:60: DB::ReadBuffer::next() @ 0x000000000a148c7b 13. /build/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) @ 0x0000000011849fb2 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]>&)>&, 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&) @ 0x0000000011841980 15. /build/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) @ 0x000000001621208e 16. /build/src/Storages/StorageReplicatedMergeTree.cpp:5228: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl[abi:se190107] const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000015f9a5fe 17. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000015ed8bfd 18. /build/src/Storages/StorageReplicatedMergeTree.cpp:2514: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x0000000015ec9aab 19. /build/src/Storages/StorageReplicatedMergeTree.cpp:2349: DB::StorageReplicatedMergeTree::executeLogEntry(DB::ReplicatedMergeTreeLogEntry&) @ 0x0000000015eba91b 20. /build/src/Storages/StorageReplicatedMergeTree.cpp:3876: bool std::__function::__policy_invoker&)>::__call_impl[abi:se190107])::$_1, bool (std::shared_ptr&)>>(std::__function::__policy_storage const*, std::shared_ptr&) @ 0x0000000015f9837e 21. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000165d6fc3 22. /build/src/Storages/StorageReplicatedMergeTree.cpp:3872: DB::StorageReplicatedMergeTree::processQueueEntry(std::shared_ptr) @ 0x0000000015efc18a 23. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001624c1b2 24. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000162f9c70 25. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x00000000162fa55a 26. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc6653 27. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000000fccc4c3 28. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc3d92 29. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fcca080 30. ? @ 0x00007fbc6213eac3 31. ? @ 0x00007fbc621d0850 (version 25.3.6.10636.altinitytest (altinity build)) 2025.07.28 11:52:19.810151 [ 3971 ] {} test_13.rmt2 (7f9b740d-015c-470e-8cc6-8ba33be0dc63): auto DB::StorageReplicatedMergeTree::processQueueEntry(ReplicatedMergeTreeQueue::SelectedEntryPtr)::(anonymous class)::operator()(LogEntryPtr &) const: Code: 86. DB::HTTPException: Received error from remote server http://146b4357c08d:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Ftest%2F01165%2Ftest_13%2Frmt%2Freplicas%2F1&part=20250728_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.6.10636.altinitytest (altinity build)) '. (RECEIVED_ERROR_FROM_REMOTE_IO_SERVER), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.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 const&, int&&, String const&, unsigned long&&, String const&) @ 0x000000000feda8d9 4. /build/src/IO/HTTPCommon.cpp:104: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x000000000feda6e2 5. /build/src/IO/HTTPCommon.cpp:93: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x000000000feda537 6. /build/src/IO/ReadWriteBufferFromHTTP.cpp:277: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x000000001184a4c4 7. /build/src/IO/ReadWriteBufferFromHTTP.cpp:285: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x000000001184a615 8. /build/src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x000000001184ae59 9. /build/src/IO/ReadWriteBufferFromHTTP.cpp:472: void std::__function::__policy_invoker::__call_impl[abi:se190107]>(std::__function::__policy_storage const*) @ 0x000000001184cedd 10. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001184858b 11. /build/src/IO/ReadWriteBufferFromHTTP.cpp:465: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x000000001184bf0b 12. /build/src/IO/ReadBuffer.h:60: DB::ReadBuffer::next() @ 0x000000000a148c7b 13. /build/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) @ 0x0000000011849fb2 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]>&)>&, 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&) @ 0x0000000011841980 15. /build/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) @ 0x000000001621208e 16. /build/src/Storages/StorageReplicatedMergeTree.cpp:5228: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl[abi:se190107] const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000015f9a5fe 17. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000015ed8bfd 18. /build/src/Storages/StorageReplicatedMergeTree.cpp:2514: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x0000000015ec9aab 19. /build/src/Storages/StorageReplicatedMergeTree.cpp:2349: DB::StorageReplicatedMergeTree::executeLogEntry(DB::ReplicatedMergeTreeLogEntry&) @ 0x0000000015eba91b 20. /build/src/Storages/StorageReplicatedMergeTree.cpp:3876: bool std::__function::__policy_invoker&)>::__call_impl[abi:se190107])::$_1, bool (std::shared_ptr&)>>(std::__function::__policy_storage const*, std::shared_ptr&) @ 0x0000000015f9837e 21. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000165d6fc3 22. /build/src/Storages/StorageReplicatedMergeTree.cpp:3872: DB::StorageReplicatedMergeTree::processQueueEntry(std::shared_ptr) @ 0x0000000015efc18a 23. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001624c1b2 24. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000162f9c70 25. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x00000000162fa55a 26. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc6653 27. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000000fccc4c3 28. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc3d92 29. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fcca080 30. ? @ 0x00007fbc6213eac3 31. ? @ 0x00007fbc621d0850 (version 25.3.6.10636.altinitytest (altinity build)) 2025.07.28 11:52:20.552828 [ 3965 ] {} test_13.alter_table1 (b6d50f9f-3cd1-4fee-aa3e-84cf679f8083): Part /var/lib/clickhouse/store/b6d/b6d50f9f-3cd1-4fee-aa3e-84cf679f8083/detached/all_28_28_0/ is broken and needs manual correction. Reason: Code: 226. DB::Exception: Marks file '/var/lib/clickhouse/store/b6d/b6d50f9f-3cd1-4fee-aa3e-84cf679f8083/detached/all_28_28_0/data.cmrk3' doesn't exist. (NO_FILE_IN_DATA_PART), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x000000000a06b56b 4. /build/src/Storages/MergeTree/MergeTreeDataPartCompact.cpp:118: DB::MergeTreeDataPartCompact::loadIndexGranularityImpl(std::shared_ptr&, DB::MergeTreeIndexGranularityInfo const&, unsigned long, DB::IDataPartStorage const&, DB::MergeTreeSettings const&) @ 0x00000000163c34b5 5. /build/src/Storages/MergeTree/MergeTreeDataPartCompact.cpp:150: DB::MergeTreeDataPartCompact::loadIndexGranularity() @ 0x00000000163c3788 6. /build/src/Storages/MergeTree/IMergeTreeDataPart.cpp:842: DB::IMergeTreeDataPart::loadColumnsChecksumsIndexes(bool, bool) @ 0x0000000016259f6d 7. /build/src/Storages/StorageReplicatedMergeTree.cpp:2237: DB::StorageReplicatedMergeTree::attachPartHelperFoundValidPart(DB::ReplicatedMergeTreeLogEntry const&) const @ 0x0000000015eb838f 8. /build/src/Storages/StorageReplicatedMergeTree.cpp:2309: DB::StorageReplicatedMergeTree::executeLogEntry(DB::ReplicatedMergeTreeLogEntry&) @ 0x0000000015eb969e 9. /build/src/Storages/StorageReplicatedMergeTree.cpp:3876: bool std::__function::__policy_invoker&)>::__call_impl[abi:se190107])::$_1, bool (std::shared_ptr&)>>(std::__function::__policy_storage const*, std::shared_ptr&) @ 0x0000000015f9837e 10. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000165d6fc3 11. /build/src/Storages/StorageReplicatedMergeTree.cpp:3872: DB::StorageReplicatedMergeTree::processQueueEntry(std::shared_ptr) @ 0x0000000015efc18a 12. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001624c1b2 13. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000162f9c70 14. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x00000000162fa55a 15. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc6653 16. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000000fccc4c3 17. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc3d92 18. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fcca080 19. ? @ 0x00007fbc6213eac3 20. ? @ 0x00007fbc621d0850 (version 25.3.6.10636.altinitytest (altinity build)) 2025.07.28 11:52:20.654999 [ 3960 ] {} test_13.rmt2 (7f9b740d-015c-470e-8cc6-8ba33be0dc63): auto DB::StorageReplicatedMergeTree::processQueueEntry(ReplicatedMergeTreeQueue::SelectedEntryPtr)::(anonymous class)::operator()(LogEntryPtr &) const: Code: 86. DB::HTTPException: Received error from remote server http://146b4357c08d:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Ftest%2F01165%2Ftest_13%2Frmt%2Freplicas%2F1&part=20250728_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.6.10636.altinitytest (altinity build)) '. (RECEIVED_ERROR_FROM_REMOTE_IO_SERVER), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.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 const&, int&&, String const&, unsigned long&&, String const&) @ 0x000000000feda8d9 4. /build/src/IO/HTTPCommon.cpp:104: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x000000000feda6e2 5. /build/src/IO/HTTPCommon.cpp:93: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x000000000feda537 6. /build/src/IO/ReadWriteBufferFromHTTP.cpp:277: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x000000001184a4c4 7. /build/src/IO/ReadWriteBufferFromHTTP.cpp:285: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x000000001184a615 8. /build/src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x000000001184ae59 9. /build/src/IO/ReadWriteBufferFromHTTP.cpp:472: void std::__function::__policy_invoker::__call_impl[abi:se190107]>(std::__function::__policy_storage const*) @ 0x000000001184cedd 10. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001184858b 11. /build/src/IO/ReadWriteBufferFromHTTP.cpp:465: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x000000001184bf0b 12. /build/src/IO/ReadBuffer.h:60: DB::ReadBuffer::next() @ 0x000000000a148c7b 13. /build/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) @ 0x0000000011849fb2 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]>&)>&, 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&) @ 0x0000000011841980 15. /build/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) @ 0x000000001621208e 16. /build/src/Storages/StorageReplicatedMergeTree.cpp:5228: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl[abi:se190107] const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000015f9a5fe 17. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000015ed8bfd 18. /build/src/Storages/StorageReplicatedMergeTree.cpp:2514: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x0000000015ec9aab 19. /build/src/Storages/StorageReplicatedMergeTree.cpp:2349: DB::StorageReplicatedMergeTree::executeLogEntry(DB::ReplicatedMergeTreeLogEntry&) @ 0x0000000015eba91b 20. /build/src/Storages/StorageReplicatedMergeTree.cpp:3876: bool std::__function::__policy_invoker&)>::__call_impl[abi:se190107])::$_1, bool (std::shared_ptr&)>>(std::__function::__policy_storage const*, std::shared_ptr&) @ 0x0000000015f9837e 21. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000165d6fc3 22. /build/src/Storages/StorageReplicatedMergeTree.cpp:3872: DB::StorageReplicatedMergeTree::processQueueEntry(std::shared_ptr) @ 0x0000000015efc18a 23. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001624c1b2 24. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000162f9c70 25. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x00000000162fa55a 26. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc6653 27. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000000fccc4c3 28. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc3d92 29. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fcca080 30. ? @ 0x00007fbc6213eac3 31. ? @ 0x00007fbc621d0850 (version 25.3.6.10636.altinitytest (altinity build)) 2025.07.28 11:52:21.541744 [ 17321 ] {} 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. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception>&, String>(int, FormatStringHelperImpl>&>::type, std::type_identity::type>, std::basic_string_view>&, String&&) @ 0x000000001385a5eb 4. /build/src/Access/SettingsConstraints.cpp:376: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000013859b18 5. /build/src/Access/SettingsConstraints.cpp:300: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000013858faf 6. /build/src/Access/SettingsConstraints.cpp:209: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000013859223 7. /build/src/Interpreters/Context.cpp:2690: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000014436134 8. /build/src/Interpreters/Context.cpp:2729: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x000000001443662b 9. /build/src/Server/HTTPHandler.cpp:457: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000001686d165 10. /build/src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x0000000016870807 11. /build/src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x0000000016907e99 12. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 13. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 14. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 15. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 16. ? @ 0x00007fbc6213eac3 17. ? @ 0x00007fbc621d0850 (version 25.3.6.10636.altinitytest (altinity build)) 2025.07.28 11:52:21.595954 [ 3971 ] {} test_13.rmt2 (7f9b740d-015c-470e-8cc6-8ba33be0dc63): auto DB::StorageReplicatedMergeTree::processQueueEntry(ReplicatedMergeTreeQueue::SelectedEntryPtr)::(anonymous class)::operator()(LogEntryPtr &) const: Code: 86. DB::HTTPException: Received error from remote server http://146b4357c08d:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Ftest%2F01165%2Ftest_13%2Frmt%2Freplicas%2F1&part=20250728_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.6.10636.altinitytest (altinity build)) '. (RECEIVED_ERROR_FROM_REMOTE_IO_SERVER), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.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 const&, int&&, String const&, unsigned long&&, String const&) @ 0x000000000feda8d9 4. /build/src/IO/HTTPCommon.cpp:104: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x000000000feda6e2 5. /build/src/IO/HTTPCommon.cpp:93: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x000000000feda537 6. /build/src/IO/ReadWriteBufferFromHTTP.cpp:277: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x000000001184a4c4 7. /build/src/IO/ReadWriteBufferFromHTTP.cpp:285: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x000000001184a615 8. /build/src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x000000001184ae59 9. /build/src/IO/ReadWriteBufferFromHTTP.cpp:472: void std::__function::__policy_invoker::__call_impl[abi:se190107]>(std::__function::__policy_storage const*) @ 0x000000001184cedd 10. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001184858b 11. /build/src/IO/ReadWriteBufferFromHTTP.cpp:465: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x000000001184bf0b 12. /build/src/IO/ReadBuffer.h:60: DB::ReadBuffer::next() @ 0x000000000a148c7b 13. /build/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) @ 0x0000000011849fb2 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]>&)>&, 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&) @ 0x0000000011841980 15. /build/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) @ 0x000000001621208e 16. /build/src/Storages/StorageReplicatedMergeTree.cpp:5228: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl[abi:se190107] const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000015f9a5fe 17. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000015ed8bfd 18. /build/src/Storages/StorageReplicatedMergeTree.cpp:2514: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x0000000015ec9aab 19. /build/src/Storages/StorageReplicatedMergeTree.cpp:2349: DB::StorageReplicatedMergeTree::executeLogEntry(DB::ReplicatedMergeTreeLogEntry&) @ 0x0000000015eba91b 20. /build/src/Storages/StorageReplicatedMergeTree.cpp:3876: bool std::__function::__policy_invoker&)>::__call_impl[abi:se190107])::$_1, bool (std::shared_ptr&)>>(std::__function::__policy_storage const*, std::shared_ptr&) @ 0x0000000015f9837e 21. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000165d6fc3 22. /build/src/Storages/StorageReplicatedMergeTree.cpp:3872: DB::StorageReplicatedMergeTree::processQueueEntry(std::shared_ptr) @ 0x0000000015efc18a 23. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001624c1b2 24. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000162f9c70 25. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x00000000162fa55a 26. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc6653 27. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000000fccc4c3 28. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc3d92 29. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fcca080 30. ? @ 0x00007fbc6213eac3 31. ? @ 0x00007fbc621d0850 (version 25.3.6.10636.altinitytest (altinity build)) 2025.07.28 11:52:21.744986 [ 12807 ] {ede3a1e4-7999-48e8-82b4-cd276787155e} executeQuery: Code: 42. DB::Exception: Number of arguments for function equals doesn't match: passed 1, should be 2: In scope SELECT 1 FROM (SELECT 1 AS c0) AS tx FULL OUTER JOIN t AS t2 ON equals(t2.a.Float32). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.6.10636.altinitytest (altinity build)) (from [::1]:58570) (comment: 03252_check_number_of_arguments_for_dynamic.sql) (query 5, line 13) (in query: SELECT 1 FROM ( SELECT 1 AS c0 ) AS tx FULL OUTER JOIN t AS t2 ON equals(t2.a.Float32);), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, unsigned long&, unsigned long&) @ 0x00000000120bbe2b 4. /build/src/Functions/IFunction.cpp:539: DB::IFunctionOverloadResolver::checkNumberOfArguments(unsigned long) const @ 0x0000000012d9640d 5. /build/src/Functions/IFunction.cpp:593: DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x0000000012d96bf3 6. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3544: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000014033cc9 7. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3838: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000014019a9e 8. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5152: DB::QueryAnalyzer::resolveJoin(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&) @ 0x00000000140480df 9. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5361: DB::QueryAnalyzer::resolveQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&) @ 0x00000000140452d6 10. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5597: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000140136f0 11. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000140127f9 12. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000014011fce 13. /build/src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000001406ce8a 14. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000014973b42 15. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000001497268d 16. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000014974d24 17. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001492924b 18. /build/src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88641 19. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 20. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 21. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 22. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 23. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 24. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 25. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 26. ? @ 0x00007fbc6213eac3 27. ? @ 0x00007fbc621d0850 2025.07.28 11:52:21.748620 [ 12807 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function equals doesn't match: passed 1, should be 2: In scope SELECT 1 FROM (SELECT 1 AS c0) AS tx FULL OUTER JOIN t AS t2 ON equals(t2.a.Float32). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, unsigned long&, unsigned long&) @ 0x00000000120bbe2b 4. /build/src/Functions/IFunction.cpp:539: DB::IFunctionOverloadResolver::checkNumberOfArguments(unsigned long) const @ 0x0000000012d9640d 5. /build/src/Functions/IFunction.cpp:593: DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x0000000012d96bf3 6. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3544: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000014033cc9 7. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3838: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000014019a9e 8. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5152: DB::QueryAnalyzer::resolveJoin(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&) @ 0x00000000140480df 9. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5361: DB::QueryAnalyzer::resolveQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&) @ 0x00000000140452d6 10. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5597: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000140136f0 11. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000140127f9 12. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000014011fce 13. /build/src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000001406ce8a 14. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000014973b42 15. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000001497268d 16. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000014974d24 17. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001492924b 18. /build/src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88641 19. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 20. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 21. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 22. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 23. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 24. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 25. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 26. ? @ 0x00007fbc6213eac3 27. ? @ 0x00007fbc621d0850 2025.07.28 11:52:22.630468 [ 3971 ] {} test_13.rmt2 (7f9b740d-015c-470e-8cc6-8ba33be0dc63): auto DB::StorageReplicatedMergeTree::processQueueEntry(ReplicatedMergeTreeQueue::SelectedEntryPtr)::(anonymous class)::operator()(LogEntryPtr &) const: Code: 86. DB::HTTPException: Received error from remote server http://146b4357c08d:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Ftest%2F01165%2Ftest_13%2Frmt%2Freplicas%2F1&part=20250728_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.6.10636.altinitytest (altinity build)) '. (RECEIVED_ERROR_FROM_REMOTE_IO_SERVER), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.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 const&, int&&, String const&, unsigned long&&, String const&) @ 0x000000000feda8d9 4. /build/src/IO/HTTPCommon.cpp:104: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x000000000feda6e2 5. /build/src/IO/HTTPCommon.cpp:93: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x000000000feda537 6. /build/src/IO/ReadWriteBufferFromHTTP.cpp:277: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x000000001184a4c4 7. /build/src/IO/ReadWriteBufferFromHTTP.cpp:285: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x000000001184a615 8. /build/src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x000000001184ae59 9. /build/src/IO/ReadWriteBufferFromHTTP.cpp:472: void std::__function::__policy_invoker::__call_impl[abi:se190107]>(std::__function::__policy_storage const*) @ 0x000000001184cedd 10. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001184858b 11. /build/src/IO/ReadWriteBufferFromHTTP.cpp:465: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x000000001184bf0b 12. /build/src/IO/ReadBuffer.h:60: DB::ReadBuffer::next() @ 0x000000000a148c7b 13. /build/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) @ 0x0000000011849fb2 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]>&)>&, 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&) @ 0x0000000011841980 15. /build/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) @ 0x000000001621208e 16. /build/src/Storages/StorageReplicatedMergeTree.cpp:5228: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl[abi:se190107] const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000015f9a5fe 17. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000015ed8bfd 18. /build/src/Storages/StorageReplicatedMergeTree.cpp:2514: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x0000000015ec9aab 19. /build/src/Storages/StorageReplicatedMergeTree.cpp:2349: DB::StorageReplicatedMergeTree::executeLogEntry(DB::ReplicatedMergeTreeLogEntry&) @ 0x0000000015eba91b 20. /build/src/Storages/StorageReplicatedMergeTree.cpp:3876: bool std::__function::__policy_invoker&)>::__call_impl[abi:se190107])::$_1, bool (std::shared_ptr&)>>(std::__function::__policy_storage const*, std::shared_ptr&) @ 0x0000000015f9837e 21. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000165d6fc3 22. /build/src/Storages/StorageReplicatedMergeTree.cpp:3872: DB::StorageReplicatedMergeTree::processQueueEntry(std::shared_ptr) @ 0x0000000015efc18a 23. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001624c1b2 24. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000162f9c70 25. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x00000000162fa55a 26. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc6653 27. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000000fccc4c3 28. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc3d92 29. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fcca080 30. ? @ 0x00007fbc6213eac3 31. ? @ 0x00007fbc621d0850 (version 25.3.6.10636.altinitytest (altinity build)) 2025.07.28 11:52:22.697146 [ 17191 ] {7191bb58-229c-4a1e-9c02-fb3ffc562114} executeQuery: Code: 47. DB::Exception: Unknown expression or function identifier `x` in scope x = 1. (UNKNOWN_IDENTIFIER) (version 25.3.6.10636.altinitytest (altinity build)) (from [::1]:57234) (comment: 02906_force_optimize_projection_name.sql) (query 4, line 18) (in query: SELECT name FROM test GROUP BY name SETTINGS force_optimize_projection_name='projection_name';), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.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&&) @ 0x000000001404b3b9 4. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3771: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000001401b849 5. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3980: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000014018e31 6. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:2925: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000001402fcbd 7. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3838: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000014019a9e 8. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:209: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000001401270e 9. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000014011fce 10. /build/src/Planner/Utils.cpp:458: DB::buildFilterInfo(std::shared_ptr, std::shared_ptr const&, std::shared_ptr&, std::unordered_set, std::equal_to, std::allocator>) @ 0x0000000013fe8bcf 11. /build/src/Planner/PlannerJoinTree.cpp:535: DB::(anonymous namespace)::buildQueryPlanForTableExpression(std::shared_ptr, std::shared_ptr const&, DB::SelectQueryInfo const&, DB::SelectQueryOptions const&, std::shared_ptr&, bool, bool) @ 0x00000000149956d3 12. /build/src/Planner/PlannerJoinTree.cpp:2252: DB::buildJoinTreeQueryPlan(std::shared_ptr const&, DB::SelectQueryInfo const&, DB::SelectQueryOptions&, std::unordered_set, std::equal_to, std::allocator> const&, std::shared_ptr&) @ 0x000000001498e109 13. /build/src/Planner/Planner.cpp:1553: DB::Planner::buildPlanForQueryNode() @ 0x0000000014979dae 14. /build/src/Planner/Planner.cpp:1308: DB::Planner::buildQueryPlanIfNeeded() @ 0x000000001497685c 15. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:255: DB::InterpreterSelectQueryAnalyzer::getQueryPlan() @ 0x000000001497476d 16. /build/src/Interpreters/executeQuery.cpp:1405: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88806 17. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 18. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 19. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 20. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 21. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 22. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 23. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 24. ? @ 0x00007fbc6213eac3 25. ? @ 0x00007fbc621d0850 2025.07.28 11:52:22.710233 [ 17191 ] {} TCPHandler: Code: 47. DB::Exception: Unknown expression or function identifier `x` in scope x = 1. (UNKNOWN_IDENTIFIER), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.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&&) @ 0x000000001404b3b9 4. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3771: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000001401b849 5. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3980: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000014018e31 6. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:2925: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000001402fcbd 7. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3838: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000014019a9e 8. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:209: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000001401270e 9. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000014011fce 10. /build/src/Planner/Utils.cpp:458: DB::buildFilterInfo(std::shared_ptr, std::shared_ptr const&, std::shared_ptr&, std::unordered_set, std::equal_to, std::allocator>) @ 0x0000000013fe8bcf 11. /build/src/Planner/PlannerJoinTree.cpp:535: DB::(anonymous namespace)::buildQueryPlanForTableExpression(std::shared_ptr, std::shared_ptr const&, DB::SelectQueryInfo const&, DB::SelectQueryOptions const&, std::shared_ptr&, bool, bool) @ 0x00000000149956d3 12. /build/src/Planner/PlannerJoinTree.cpp:2252: DB::buildJoinTreeQueryPlan(std::shared_ptr const&, DB::SelectQueryInfo const&, DB::SelectQueryOptions&, std::unordered_set, std::equal_to, std::allocator> const&, std::shared_ptr&) @ 0x000000001498e109 13. /build/src/Planner/Planner.cpp:1553: DB::Planner::buildPlanForQueryNode() @ 0x0000000014979dae 14. /build/src/Planner/Planner.cpp:1308: DB::Planner::buildQueryPlanIfNeeded() @ 0x000000001497685c 15. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:255: DB::InterpreterSelectQueryAnalyzer::getQueryPlan() @ 0x000000001497476d 16. /build/src/Interpreters/executeQuery.cpp:1405: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88806 17. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 18. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 19. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 20. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 21. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 22. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 23. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 24. ? @ 0x00007fbc6213eac3 25. ? @ 0x00007fbc621d0850 2025.07.28 11:52:23.309753 [ 5112 ] {4536aeae-3892-4350-98b9-fcba61eeb558} executeQuery: Code: 160. DB::Exception: Estimated query execution time (604829.51807 seconds) is too long. Maximum: 2. Estimated rows to process: 100000000 (166 read in 1.00402 seconds).: While executing NumbersRange. (TOO_SLOW) (version 25.3.6.10636.altinitytest (altinity build)) (from [::1]:58532) (comment: 02896_max_execution_time_with_break_overflow_mode.sql) (query 3, line 8) (in query: -- Query returns an error when runtime is estimated after timeout_before_checking_execution_speed passed SELECT * FROM numbers(100000000) SETTINGS max_block_size=1, timeout_before_checking_execution_speed=1, max_estimated_execution_time=2, timeout_overflow_mode='throw' FORMAT Null;), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, double&, int&&, unsigned long&, unsigned long&, double&) @ 0x0000000013bb2a79 4. /build/src/QueryPipeline/ExecutionSpeedLimits.cpp:87: DB::ExecutionSpeedLimits::throttle(unsigned long, unsigned long, unsigned long, unsigned long, DB::OverflowMode) const @ 0x0000000013bb274f 5. /build/src/QueryPipeline/ReadProgressCallback.cpp:131: DB::ReadProgressCallback::onProgress(unsigned long, unsigned long, std::list> const&) @ 0x0000000013bb1f59 6. /build/src/Processors/Executors/ExecutionThreadContext.cpp:68: DB::ExecutionThreadContext::executeTask() @ 0x00000000169bd08f 7. /build/src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x00000000169b2105 8. /build/src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeSingleThread(unsigned long) @ 0x00000000169b23be 9. /build/src/Processors/Executors/PipelineExecutor.cpp:454: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x00000000169b0be7 10. /build/src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x00000000169b03f4 11. /build/src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:se190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169bfeab 12. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc3d92 13. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fcca080 14. ? @ 0x00007fbc6213eac3 15. ? @ 0x00007fbc621d0850 2025.07.28 11:52:23.312302 [ 5112 ] {} TCPHandler: Code: 160. DB::Exception: Estimated query execution time (604829.51807 seconds) is too long. Maximum: 2. Estimated rows to process: 100000000 (166 read in 1.00402 seconds).: While executing NumbersRange. (TOO_SLOW), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, double&, int&&, unsigned long&, unsigned long&, double&) @ 0x0000000013bb2a79 4. /build/src/QueryPipeline/ExecutionSpeedLimits.cpp:87: DB::ExecutionSpeedLimits::throttle(unsigned long, unsigned long, unsigned long, unsigned long, DB::OverflowMode) const @ 0x0000000013bb274f 5. /build/src/QueryPipeline/ReadProgressCallback.cpp:131: DB::ReadProgressCallback::onProgress(unsigned long, unsigned long, std::list> const&) @ 0x0000000013bb1f59 6. /build/src/Processors/Executors/ExecutionThreadContext.cpp:68: DB::ExecutionThreadContext::executeTask() @ 0x00000000169bd08f 7. /build/src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x00000000169b2105 8. /build/src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeSingleThread(unsigned long) @ 0x00000000169b23be 9. /build/src/Processors/Executors/PipelineExecutor.cpp:454: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x00000000169b0be7 10. /build/src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x00000000169b03f4 11. /build/src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:se190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169bfeab 12. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc3d92 13. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fcca080 14. ? @ 0x00007fbc6213eac3 15. ? @ 0x00007fbc621d0850 Job's origin stack trace: 0. /build/src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000000fc33b84 1. /build/src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000000fcc2ea7 2. /build/src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fcc535c 3. /build/src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000000fcc584d 4. /build/src/Common/ThreadPool.h:279: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x00000000169bf193 5. /build/src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x00000000169bf518 6. /build/src/Server/TCPHandler.cpp:1237: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x00000000168f1525 7. /build/src/Server/TCPHandler.cpp:678: DB::TCPHandler::runImpl() @ 0x00000000168e68e5 8. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 9. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 10. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 11. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 12. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 13. ? @ 0x00007fbc6213eac3 14. ? @ 0x00007fbc621d0850 2025.07.28 11:52:23.390587 [ 3970 ] {} test_13.rmt2 (7f9b740d-015c-470e-8cc6-8ba33be0dc63): auto DB::StorageReplicatedMergeTree::processQueueEntry(ReplicatedMergeTreeQueue::SelectedEntryPtr)::(anonymous class)::operator()(LogEntryPtr &) const: Code: 86. DB::HTTPException: Received error from remote server http://146b4357c08d:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Ftest%2F01165%2Ftest_13%2Frmt%2Freplicas%2F1&part=20250728_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.6.10636.altinitytest (altinity build)) '. (RECEIVED_ERROR_FROM_REMOTE_IO_SERVER), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.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 const&, int&&, String const&, unsigned long&&, String const&) @ 0x000000000feda8d9 4. /build/src/IO/HTTPCommon.cpp:104: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x000000000feda6e2 5. /build/src/IO/HTTPCommon.cpp:93: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x000000000feda537 6. /build/src/IO/ReadWriteBufferFromHTTP.cpp:277: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x000000001184a4c4 7. /build/src/IO/ReadWriteBufferFromHTTP.cpp:285: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x000000001184a615 8. /build/src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x000000001184ae59 9. /build/src/IO/ReadWriteBufferFromHTTP.cpp:472: void std::__function::__policy_invoker::__call_impl[abi:se190107]>(std::__function::__policy_storage const*) @ 0x000000001184cedd 10. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001184858b 11. /build/src/IO/ReadWriteBufferFromHTTP.cpp:465: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x000000001184bf0b 12. /build/src/IO/ReadBuffer.h:60: DB::ReadBuffer::next() @ 0x000000000a148c7b 13. /build/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) @ 0x0000000011849fb2 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]>&)>&, 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&) @ 0x0000000011841980 15. /build/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) @ 0x000000001621208e 16. /build/src/Storages/StorageReplicatedMergeTree.cpp:5228: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl[abi:se190107] const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000015f9a5fe 17. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000015ed8bfd 18. /build/src/Storages/StorageReplicatedMergeTree.cpp:2514: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x0000000015ec9aab 19. /build/src/Storages/StorageReplicatedMergeTree.cpp:2349: DB::StorageReplicatedMergeTree::executeLogEntry(DB::ReplicatedMergeTreeLogEntry&) @ 0x0000000015eba91b 20. /build/src/Storages/StorageReplicatedMergeTree.cpp:3876: bool std::__function::__policy_invoker&)>::__call_impl[abi:se190107])::$_1, bool (std::shared_ptr&)>>(std::__function::__policy_storage const*, std::shared_ptr&) @ 0x0000000015f9837e 21. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000165d6fc3 22. /build/src/Storages/StorageReplicatedMergeTree.cpp:3872: DB::StorageReplicatedMergeTree::processQueueEntry(std::shared_ptr) @ 0x0000000015efc18a 23. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001624c1b2 24. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000162f9c70 25. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x00000000162fa55a 26. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc6653 27. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000000fccc4c3 28. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc3d92 29. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fcca080 30. ? @ 0x00007fbc6213eac3 31. ? @ 0x00007fbc621d0850 (version 25.3.6.10636.altinitytest (altinity build)) 2025.07.28 11:52:23.568471 [ 3965 ] {} test_13.alter_table0 (d9d10d50-2ce9-41b4-bbf8-b86fcdd19efe): Part /var/lib/clickhouse/store/d9d/d9d10d50-2ce9-41b4-bbf8-b86fcdd19efe/detached/all_40_40_0/ is broken and needs manual correction. Reason: Code: 226. DB::Exception: No checksums.txt in part all_69_69_0. (NO_FILE_IN_DATA_PART), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000a9b78ab 4. /build/src/Storages/MergeTree/IMergeTreeDataPart.cpp:1336: DB::IMergeTreeDataPart::loadChecksums(bool) @ 0x000000001625c892 5. /build/src/Storages/MergeTree/IMergeTreeDataPart.cpp:840: DB::IMergeTreeDataPart::loadColumnsChecksumsIndexes(bool, bool) @ 0x0000000016259f66 6. /build/src/Storages/StorageReplicatedMergeTree.cpp:2237: DB::StorageReplicatedMergeTree::attachPartHelperFoundValidPart(DB::ReplicatedMergeTreeLogEntry const&) const @ 0x0000000015eb838f 7. /build/src/Storages/StorageReplicatedMergeTree.cpp:2309: DB::StorageReplicatedMergeTree::executeLogEntry(DB::ReplicatedMergeTreeLogEntry&) @ 0x0000000015eb969e 8. /build/src/Storages/StorageReplicatedMergeTree.cpp:3876: bool std::__function::__policy_invoker&)>::__call_impl[abi:se190107])::$_1, bool (std::shared_ptr&)>>(std::__function::__policy_storage const*, std::shared_ptr&) @ 0x0000000015f9837e 9. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000165d6fc3 10. /build/src/Storages/StorageReplicatedMergeTree.cpp:3872: DB::StorageReplicatedMergeTree::processQueueEntry(std::shared_ptr) @ 0x0000000015efc18a 11. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001624c1b2 12. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000162f9c70 13. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x00000000162fa55a 14. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc6653 15. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000000fccc4c3 16. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc3d92 17. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fcca080 18. ? @ 0x00007fbc6213eac3 19. ? @ 0x00007fbc621d0850 (version 25.3.6.10636.altinitytest (altinity build)) 2025.07.28 11:52:23.574021 [ 17251 ] {64637cc9-ae01-4f6c-b42f-ee04a88171c0} executeQuery: Code: 636. DB::Exception: The table structure cannot be extracted from a CSV format file, because there are no files with provided path in S3ObjectStorage or all files are empty. You can specify table structure manually: The table structure cannot be extracted from a CSV format file. You can specify the structure manually. (CANNOT_EXTRACT_TABLE_STRUCTURE) (version 25.3.6.10636.altinitytest (altinity build)) (from [::1]:58016) (comment: 03036_reading_s3_archives.sql) (query 10, line 13) (in query: select id, data, _size, _file, _path from s3(s3_conn, filename='03036_archive2.zip :: nonexistent.csv');), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&, String&&) @ 0x000000000b2edfab 4. /build/src/Storages/ObjectStorage/ReadBufferIterator.cpp:201: DB::ReadBufferIterator::next() @ 0x00000000132ca8f8 5. /build/src/Formats/ReadSchemaUtils.cpp:152: DB::readSchemaFromFormatImpl(std::optional, std::optional const&, DB::IReadBufferIterator&, std::shared_ptr const&) @ 0x00000000169766c7 6. /build/src/Formats/ReadSchemaUtils.cpp:548: DB::readSchemaFromFormat(String const&, std::optional const&, DB::IReadBufferIterator&, std::shared_ptr const&) @ 0x000000001697a742 7. /build/src/Storages/ObjectStorage/StorageObjectStorage.cpp:517: DB::StorageObjectStorage::resolveSchemaFromData(std::shared_ptr const&, std::shared_ptr const&, std::optional const&, String&, std::shared_ptr const&) @ 0x00000000132c3de0 8. /build/src/Storages/ObjectStorage/Utils.cpp:68: DB::resolveSchemaAndFormat(DB::ColumnsDescription&, String&, std::shared_ptr, std::shared_ptr const&, std::optional, String&, std::shared_ptr const&) @ 0x000000001334ec15 9. /build/src/Storages/ObjectStorage/StorageObjectStorage.cpp:134: 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) @ 0x00000000132c03cc 10. /build/contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: DB::StorageObjectStorage* std::construct_at[abi:se190107]&, std::shared_ptr, std::shared_ptr&, DB::StorageID, DB::ColumnsDescription&, DB::ConstraintsDescription, String, std::nullopt_t const&, DB::LoadingStrictnessLevel, bool const&, 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 const&, std::nullptr_t&&) @ 0x00000000118910aa 11. /build/contrib/llvm-project/libcxx/include/__memory/construct_at.h:49: std::shared_ptr std::allocate_shared[abi:se190107], std::shared_ptr&, std::shared_ptr, std::shared_ptr&, DB::StorageID, DB::ColumnsDescription&, DB::ConstraintsDescription, String, std::nullopt_t const&, DB::LoadingStrictnessLevel, bool const&, 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 const&, std::nullptr_t&&) @ 0x0000000011890e84 12. /build/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 @ 0x0000000011869d1f 13. /build/src/TableFunctions/ITableFunction.cpp:36: DB::ITableFunction::execute(std::shared_ptr const&, std::shared_ptr, String const&, DB::ColumnsDescription, bool, bool) const @ 0x00000000131e9fc3 14. /build/src/Interpreters/Context.cpp:2501: DB::Context::executeTableFunction(std::shared_ptr const&, std::shared_ptr const&) @ 0x00000000144345b2 15. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:4975: DB::QueryAnalyzer::resolveTableFunction(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&, bool) @ 0x000000001401e9f9 16. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5342: DB::QueryAnalyzer::resolveQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&) @ 0x00000000140452bf 17. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5597: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000140136f0 18. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000140127f9 19. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000014011fce 20. /build/src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000001406ce8a 21. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000014973b42 22. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000001497268d 23. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000014974d24 24. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001492924b 25. /build/src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88641 26. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 27. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 28. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 29. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 30. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 31. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 2025.07.28 11:52:23.581866 [ 17251 ] {} TCPHandler: Code: 636. DB::Exception: The table structure cannot be extracted from a CSV format file, because there are no files with provided path in S3ObjectStorage or all files are empty. You can specify table structure manually: The table structure cannot be extracted from a CSV format file. You can specify the structure manually. (CANNOT_EXTRACT_TABLE_STRUCTURE), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&, String&&) @ 0x000000000b2edfab 4. /build/src/Storages/ObjectStorage/ReadBufferIterator.cpp:201: DB::ReadBufferIterator::next() @ 0x00000000132ca8f8 5. /build/src/Formats/ReadSchemaUtils.cpp:152: DB::readSchemaFromFormatImpl(std::optional, std::optional const&, DB::IReadBufferIterator&, std::shared_ptr const&) @ 0x00000000169766c7 6. /build/src/Formats/ReadSchemaUtils.cpp:548: DB::readSchemaFromFormat(String const&, std::optional const&, DB::IReadBufferIterator&, std::shared_ptr const&) @ 0x000000001697a742 7. /build/src/Storages/ObjectStorage/StorageObjectStorage.cpp:517: DB::StorageObjectStorage::resolveSchemaFromData(std::shared_ptr const&, std::shared_ptr const&, std::optional const&, String&, std::shared_ptr const&) @ 0x00000000132c3de0 8. /build/src/Storages/ObjectStorage/Utils.cpp:68: DB::resolveSchemaAndFormat(DB::ColumnsDescription&, String&, std::shared_ptr, std::shared_ptr const&, std::optional, String&, std::shared_ptr const&) @ 0x000000001334ec15 9. /build/src/Storages/ObjectStorage/StorageObjectStorage.cpp:134: 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) @ 0x00000000132c03cc 10. /build/contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: DB::StorageObjectStorage* std::construct_at[abi:se190107]&, std::shared_ptr, std::shared_ptr&, DB::StorageID, DB::ColumnsDescription&, DB::ConstraintsDescription, String, std::nullopt_t const&, DB::LoadingStrictnessLevel, bool const&, 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 const&, std::nullptr_t&&) @ 0x00000000118910aa 11. /build/contrib/llvm-project/libcxx/include/__memory/construct_at.h:49: std::shared_ptr std::allocate_shared[abi:se190107], std::shared_ptr&, std::shared_ptr, std::shared_ptr&, DB::StorageID, DB::ColumnsDescription&, DB::ConstraintsDescription, String, std::nullopt_t const&, DB::LoadingStrictnessLevel, bool const&, 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 const&, std::nullptr_t&&) @ 0x0000000011890e84 12. /build/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 @ 0x0000000011869d1f 13. /build/src/TableFunctions/ITableFunction.cpp:36: DB::ITableFunction::execute(std::shared_ptr const&, std::shared_ptr, String const&, DB::ColumnsDescription, bool, bool) const @ 0x00000000131e9fc3 14. /build/src/Interpreters/Context.cpp:2501: DB::Context::executeTableFunction(std::shared_ptr const&, std::shared_ptr const&) @ 0x00000000144345b2 15. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:4975: DB::QueryAnalyzer::resolveTableFunction(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&, bool) @ 0x000000001401e9f9 16. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5342: DB::QueryAnalyzer::resolveQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&) @ 0x00000000140452bf 17. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5597: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000140136f0 18. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000140127f9 19. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000014011fce 20. /build/src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000001406ce8a 21. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000014973b42 22. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000001497268d 23. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000014974d24 24. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001492924b 25. /build/src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88641 26. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 27. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 28. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 29. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 30. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 31. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 2025.07.28 11:52:23.753891 [ 3965 ] {} test_13.alter_table0 (d9d10d50-2ce9-41b4-bbf8-b86fcdd19efe): Part /var/lib/clickhouse/store/d9d/d9d10d50-2ce9-41b4-bbf8-b86fcdd19efe/detached/all_42_42_0/ is broken and needs manual correction. Reason: Code: 226. DB::Exception: No columns.txt in part all_69_69_0, expected path store/d9d/d9d10d50-2ce9-41b4-bbf8-b86fcdd19efe/detached/all_42_42_0/columns.txt on drive default. (NO_FILE_IN_DATA_PART), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, String&, String&&) @ 0x0000000012da2e0b 4. /build/src/Storages/MergeTree/IMergeTreeDataPart.cpp:1629: DB::IMergeTreeDataPart::loadColumns(bool) @ 0x000000001625bb62 5. /build/src/Storages/MergeTree/IMergeTreeDataPart.cpp:839: DB::IMergeTreeDataPart::loadColumnsChecksumsIndexes(bool, bool) @ 0x0000000016259f5b 6. /build/src/Storages/StorageReplicatedMergeTree.cpp:2237: DB::StorageReplicatedMergeTree::attachPartHelperFoundValidPart(DB::ReplicatedMergeTreeLogEntry const&) const @ 0x0000000015eb838f 7. /build/src/Storages/StorageReplicatedMergeTree.cpp:2309: DB::StorageReplicatedMergeTree::executeLogEntry(DB::ReplicatedMergeTreeLogEntry&) @ 0x0000000015eb969e 8. /build/src/Storages/StorageReplicatedMergeTree.cpp:3876: bool std::__function::__policy_invoker&)>::__call_impl[abi:se190107])::$_1, bool (std::shared_ptr&)>>(std::__function::__policy_storage const*, std::shared_ptr&) @ 0x0000000015f9837e 9. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000165d6fc3 10. /build/src/Storages/StorageReplicatedMergeTree.cpp:3872: DB::StorageReplicatedMergeTree::processQueueEntry(std::shared_ptr) @ 0x0000000015efc18a 11. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001624c1b2 12. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000162f9c70 13. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x00000000162fa55a 14. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc6653 15. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000000fccc4c3 16. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc3d92 17. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fcca080 18. ? @ 0x00007fbc6213eac3 19. ? @ 0x00007fbc621d0850 (version 25.3.6.10636.altinitytest (altinity build)) 2025.07.28 11:52:24.142187 [ 17251 ] {8f7c181c-c057-4b2f-9489-baca29712749} executeQuery: Code: 636. DB::Exception: The table structure cannot be extracted from a CSV format file, because there are no files with provided path in S3ObjectStorage or all files are empty. You can specify table structure manually: The table structure cannot be extracted from a CSV format file. You can specify the structure manually. (CANNOT_EXTRACT_TABLE_STRUCTURE) (version 25.3.6.10636.altinitytest (altinity build)) (from [::1]:58016) (comment: 03036_reading_s3_archives.sql) (query 11, line 14) (in query: select id, data, _size, _file, _path from s3(s3_conn, filename='03036_archive2.zip :: nonexistent{2..3}.csv');), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&, String&&) @ 0x000000000b2edfab 4. /build/src/Storages/ObjectStorage/ReadBufferIterator.cpp:201: DB::ReadBufferIterator::next() @ 0x00000000132ca8f8 5. /build/src/Formats/ReadSchemaUtils.cpp:152: DB::readSchemaFromFormatImpl(std::optional, std::optional const&, DB::IReadBufferIterator&, std::shared_ptr const&) @ 0x00000000169766c7 6. /build/src/Formats/ReadSchemaUtils.cpp:548: DB::readSchemaFromFormat(String const&, std::optional const&, DB::IReadBufferIterator&, std::shared_ptr const&) @ 0x000000001697a742 7. /build/src/Storages/ObjectStorage/StorageObjectStorage.cpp:517: DB::StorageObjectStorage::resolveSchemaFromData(std::shared_ptr const&, std::shared_ptr const&, std::optional const&, String&, std::shared_ptr const&) @ 0x00000000132c3de0 8. /build/src/Storages/ObjectStorage/Utils.cpp:68: DB::resolveSchemaAndFormat(DB::ColumnsDescription&, String&, std::shared_ptr, std::shared_ptr const&, std::optional, String&, std::shared_ptr const&) @ 0x000000001334ec15 9. /build/src/Storages/ObjectStorage/StorageObjectStorage.cpp:134: 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) @ 0x00000000132c03cc 10. /build/contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: DB::StorageObjectStorage* std::construct_at[abi:se190107]&, std::shared_ptr, std::shared_ptr&, DB::StorageID, DB::ColumnsDescription&, DB::ConstraintsDescription, String, std::nullopt_t const&, DB::LoadingStrictnessLevel, bool const&, 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 const&, std::nullptr_t&&) @ 0x00000000118910aa 11. /build/contrib/llvm-project/libcxx/include/__memory/construct_at.h:49: std::shared_ptr std::allocate_shared[abi:se190107], std::shared_ptr&, std::shared_ptr, std::shared_ptr&, DB::StorageID, DB::ColumnsDescription&, DB::ConstraintsDescription, String, std::nullopt_t const&, DB::LoadingStrictnessLevel, bool const&, 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 const&, std::nullptr_t&&) @ 0x0000000011890e84 12. /build/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 @ 0x0000000011869d1f 13. /build/src/TableFunctions/ITableFunction.cpp:36: DB::ITableFunction::execute(std::shared_ptr const&, std::shared_ptr, String const&, DB::ColumnsDescription, bool, bool) const @ 0x00000000131e9fc3 14. /build/src/Interpreters/Context.cpp:2501: DB::Context::executeTableFunction(std::shared_ptr const&, std::shared_ptr const&) @ 0x00000000144345b2 15. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:4975: DB::QueryAnalyzer::resolveTableFunction(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&, bool) @ 0x000000001401e9f9 16. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5342: DB::QueryAnalyzer::resolveQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&) @ 0x00000000140452bf 17. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5597: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000140136f0 18. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000140127f9 19. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000014011fce 20. /build/src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000001406ce8a 21. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000014973b42 22. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000001497268d 23. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000014974d24 24. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001492924b 25. /build/src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88641 26. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 27. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 28. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 29. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 30. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 31. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 2025.07.28 11:52:24.172413 [ 17251 ] {} TCPHandler: Code: 636. DB::Exception: The table structure cannot be extracted from a CSV format file, because there are no files with provided path in S3ObjectStorage or all files are empty. You can specify table structure manually: The table structure cannot be extracted from a CSV format file. You can specify the structure manually. (CANNOT_EXTRACT_TABLE_STRUCTURE), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&, String&&) @ 0x000000000b2edfab 4. /build/src/Storages/ObjectStorage/ReadBufferIterator.cpp:201: DB::ReadBufferIterator::next() @ 0x00000000132ca8f8 5. /build/src/Formats/ReadSchemaUtils.cpp:152: DB::readSchemaFromFormatImpl(std::optional, std::optional const&, DB::IReadBufferIterator&, std::shared_ptr const&) @ 0x00000000169766c7 6. /build/src/Formats/ReadSchemaUtils.cpp:548: DB::readSchemaFromFormat(String const&, std::optional const&, DB::IReadBufferIterator&, std::shared_ptr const&) @ 0x000000001697a742 7. /build/src/Storages/ObjectStorage/StorageObjectStorage.cpp:517: DB::StorageObjectStorage::resolveSchemaFromData(std::shared_ptr const&, std::shared_ptr const&, std::optional const&, String&, std::shared_ptr const&) @ 0x00000000132c3de0 8. /build/src/Storages/ObjectStorage/Utils.cpp:68: DB::resolveSchemaAndFormat(DB::ColumnsDescription&, String&, std::shared_ptr, std::shared_ptr const&, std::optional, String&, std::shared_ptr const&) @ 0x000000001334ec15 9. /build/src/Storages/ObjectStorage/StorageObjectStorage.cpp:134: 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) @ 0x00000000132c03cc 10. /build/contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: DB::StorageObjectStorage* std::construct_at[abi:se190107]&, std::shared_ptr, std::shared_ptr&, DB::StorageID, DB::ColumnsDescription&, DB::ConstraintsDescription, String, std::nullopt_t const&, DB::LoadingStrictnessLevel, bool const&, 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 const&, std::nullptr_t&&) @ 0x00000000118910aa 11. /build/contrib/llvm-project/libcxx/include/__memory/construct_at.h:49: std::shared_ptr std::allocate_shared[abi:se190107], std::shared_ptr&, std::shared_ptr, std::shared_ptr&, DB::StorageID, DB::ColumnsDescription&, DB::ConstraintsDescription, String, std::nullopt_t const&, DB::LoadingStrictnessLevel, bool const&, 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 const&, std::nullptr_t&&) @ 0x0000000011890e84 12. /build/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 @ 0x0000000011869d1f 13. /build/src/TableFunctions/ITableFunction.cpp:36: DB::ITableFunction::execute(std::shared_ptr const&, std::shared_ptr, String const&, DB::ColumnsDescription, bool, bool) const @ 0x00000000131e9fc3 14. /build/src/Interpreters/Context.cpp:2501: DB::Context::executeTableFunction(std::shared_ptr const&, std::shared_ptr const&) @ 0x00000000144345b2 15. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:4975: DB::QueryAnalyzer::resolveTableFunction(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&, bool) @ 0x000000001401e9f9 16. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5342: DB::QueryAnalyzer::resolveQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&) @ 0x00000000140452bf 17. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5597: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000140136f0 18. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000140127f9 19. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000014011fce 20. /build/src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000001406ce8a 21. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000014973b42 22. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000001497268d 23. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000014974d24 24. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001492924b 25. /build/src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88641 26. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 27. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 28. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 29. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 30. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 31. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 2025.07.28 11:52:24.512775 [ 3963 ] {} test_13.rmt2 (7f9b740d-015c-470e-8cc6-8ba33be0dc63): auto DB::StorageReplicatedMergeTree::processQueueEntry(ReplicatedMergeTreeQueue::SelectedEntryPtr)::(anonymous class)::operator()(LogEntryPtr &) const: Code: 86. DB::HTTPException: Received error from remote server http://146b4357c08d:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Ftest%2F01165%2Ftest_13%2Frmt%2Freplicas%2F1&part=20250728_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.6.10636.altinitytest (altinity build)) '. (RECEIVED_ERROR_FROM_REMOTE_IO_SERVER), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.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 const&, int&&, String const&, unsigned long&&, String const&) @ 0x000000000feda8d9 4. /build/src/IO/HTTPCommon.cpp:104: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x000000000feda6e2 5. /build/src/IO/HTTPCommon.cpp:93: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x000000000feda537 6. /build/src/IO/ReadWriteBufferFromHTTP.cpp:277: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x000000001184a4c4 7. /build/src/IO/ReadWriteBufferFromHTTP.cpp:285: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x000000001184a615 8. /build/src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x000000001184ae59 9. /build/src/IO/ReadWriteBufferFromHTTP.cpp:472: void std::__function::__policy_invoker::__call_impl[abi:se190107]>(std::__function::__policy_storage const*) @ 0x000000001184cedd 10. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001184858b 11. /build/src/IO/ReadWriteBufferFromHTTP.cpp:465: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x000000001184bf0b 12. /build/src/IO/ReadBuffer.h:60: DB::ReadBuffer::next() @ 0x000000000a148c7b 13. /build/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) @ 0x0000000011849fb2 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]>&)>&, 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&) @ 0x0000000011841980 15. /build/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) @ 0x000000001621208e 16. /build/src/Storages/StorageReplicatedMergeTree.cpp:5228: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl[abi:se190107] const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000015f9a5fe 17. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000015ed8bfd 18. /build/src/Storages/StorageReplicatedMergeTree.cpp:2514: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x0000000015ec9aab 19. /build/src/Storages/StorageReplicatedMergeTree.cpp:2349: DB::StorageReplicatedMergeTree::executeLogEntry(DB::ReplicatedMergeTreeLogEntry&) @ 0x0000000015eba91b 20. /build/src/Storages/StorageReplicatedMergeTree.cpp:3876: bool std::__function::__policy_invoker&)>::__call_impl[abi:se190107])::$_1, bool (std::shared_ptr&)>>(std::__function::__policy_storage const*, std::shared_ptr&) @ 0x0000000015f9837e 21. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000165d6fc3 22. /build/src/Storages/StorageReplicatedMergeTree.cpp:3872: DB::StorageReplicatedMergeTree::processQueueEntry(std::shared_ptr) @ 0x0000000015efc18a 23. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001624c1b2 24. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000162f9c70 25. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x00000000162fa55a 26. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc6653 27. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000000fccc4c3 28. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc3d92 29. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fcca080 30. ? @ 0x00007fbc6213eac3 31. ? @ 0x00007fbc621d0850 (version 25.3.6.10636.altinitytest (altinity build)) 2025.07.28 11:52:24.743551 [ 17256 ] {d3861f72-f8b2-4997-b0ae-cc4e4c924bd7} executeQuery: Code: 47. DB::Exception: Unknown expression or function identifier `x` in scope x = 1. (UNKNOWN_IDENTIFIER) (version 25.3.6.10636.altinitytest (altinity build)) (from [::1]:57328) (comment: 00234_disjunctive_equality_chains_optimization.sql) (query 3, line 3) (in query: SELECT sum(id = 3 OR id = 1 OR id = 2) AS x, sum(id = 3 OR id = 1 OR id = 2) AS x FROM foo_00234;), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.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&&) @ 0x000000001404b3b9 4. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3771: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000001401b849 5. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3980: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000014018e31 6. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:2925: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000001402fcbd 7. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3838: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000014019a9e 8. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:209: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000001401270e 9. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000014011fce 10. /build/src/Planner/Utils.cpp:458: DB::buildFilterInfo(std::shared_ptr, std::shared_ptr const&, std::shared_ptr&, std::unordered_set, std::equal_to, std::allocator>) @ 0x0000000013fe8bcf 11. /build/src/Planner/PlannerJoinTree.cpp:535: DB::(anonymous namespace)::buildQueryPlanForTableExpression(std::shared_ptr, std::shared_ptr const&, DB::SelectQueryInfo const&, DB::SelectQueryOptions const&, std::shared_ptr&, bool, bool) @ 0x00000000149956d3 12. /build/src/Planner/PlannerJoinTree.cpp:2252: DB::buildJoinTreeQueryPlan(std::shared_ptr const&, DB::SelectQueryInfo const&, DB::SelectQueryOptions&, std::unordered_set, std::equal_to, std::allocator> const&, std::shared_ptr&) @ 0x000000001498e109 13. /build/src/Planner/Planner.cpp:1553: DB::Planner::buildPlanForQueryNode() @ 0x0000000014979dae 14. /build/src/Planner/Planner.cpp:1308: DB::Planner::buildQueryPlanIfNeeded() @ 0x000000001497685c 15. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:255: DB::InterpreterSelectQueryAnalyzer::getQueryPlan() @ 0x000000001497476d 16. /build/src/Interpreters/executeQuery.cpp:1405: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88806 17. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 18. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 19. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 20. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 21. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 22. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 23. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 24. ? @ 0x00007fbc6213eac3 25. ? @ 0x00007fbc621d0850 2025.07.28 11:52:24.748517 [ 17256 ] {} TCPHandler: Code: 47. DB::Exception: Unknown expression or function identifier `x` in scope x = 1. (UNKNOWN_IDENTIFIER), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.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&&) @ 0x000000001404b3b9 4. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3771: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000001401b849 5. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3980: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000014018e31 6. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:2925: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000001402fcbd 7. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3838: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000014019a9e 8. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:209: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000001401270e 9. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000014011fce 10. /build/src/Planner/Utils.cpp:458: DB::buildFilterInfo(std::shared_ptr, std::shared_ptr const&, std::shared_ptr&, std::unordered_set, std::equal_to, std::allocator>) @ 0x0000000013fe8bcf 11. /build/src/Planner/PlannerJoinTree.cpp:535: DB::(anonymous namespace)::buildQueryPlanForTableExpression(std::shared_ptr, std::shared_ptr const&, DB::SelectQueryInfo const&, DB::SelectQueryOptions const&, std::shared_ptr&, bool, bool) @ 0x00000000149956d3 12. /build/src/Planner/PlannerJoinTree.cpp:2252: DB::buildJoinTreeQueryPlan(std::shared_ptr const&, DB::SelectQueryInfo const&, DB::SelectQueryOptions&, std::unordered_set, std::equal_to, std::allocator> const&, std::shared_ptr&) @ 0x000000001498e109 13. /build/src/Planner/Planner.cpp:1553: DB::Planner::buildPlanForQueryNode() @ 0x0000000014979dae 14. /build/src/Planner/Planner.cpp:1308: DB::Planner::buildQueryPlanIfNeeded() @ 0x000000001497685c 15. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:255: DB::InterpreterSelectQueryAnalyzer::getQueryPlan() @ 0x000000001497476d 16. /build/src/Interpreters/executeQuery.cpp:1405: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88806 17. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 18. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 19. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 20. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 21. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 22. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 23. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 24. ? @ 0x00007fbc6213eac3 25. ? @ 0x00007fbc621d0850 2025.07.28 11:52:25.411365 [ 3970 ] {} test_13.rmt2 (7f9b740d-015c-470e-8cc6-8ba33be0dc63): auto DB::StorageReplicatedMergeTree::processQueueEntry(ReplicatedMergeTreeQueue::SelectedEntryPtr)::(anonymous class)::operator()(LogEntryPtr &) const: Code: 86. DB::HTTPException: Received error from remote server http://146b4357c08d:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Ftest%2F01165%2Ftest_13%2Frmt%2Freplicas%2F1&part=20250728_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.6.10636.altinitytest (altinity build)) '. (RECEIVED_ERROR_FROM_REMOTE_IO_SERVER), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.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 const&, int&&, String const&, unsigned long&&, String const&) @ 0x000000000feda8d9 4. /build/src/IO/HTTPCommon.cpp:104: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x000000000feda6e2 5. /build/src/IO/HTTPCommon.cpp:93: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x000000000feda537 6. /build/src/IO/ReadWriteBufferFromHTTP.cpp:277: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x000000001184a4c4 7. /build/src/IO/ReadWriteBufferFromHTTP.cpp:285: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x000000001184a615 8. /build/src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x000000001184ae59 9. /build/src/IO/ReadWriteBufferFromHTTP.cpp:472: void std::__function::__policy_invoker::__call_impl[abi:se190107]>(std::__function::__policy_storage const*) @ 0x000000001184cedd 10. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001184858b 11. /build/src/IO/ReadWriteBufferFromHTTP.cpp:465: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x000000001184bf0b 12. /build/src/IO/ReadBuffer.h:60: DB::ReadBuffer::next() @ 0x000000000a148c7b 13. /build/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) @ 0x0000000011849fb2 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]>&)>&, 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&) @ 0x0000000011841980 15. /build/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) @ 0x000000001621208e 16. /build/src/Storages/StorageReplicatedMergeTree.cpp:5228: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl[abi:se190107] const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000015f9a5fe 17. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000015ed8bfd 18. /build/src/Storages/StorageReplicatedMergeTree.cpp:2514: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x0000000015ec9aab 19. /build/src/Storages/StorageReplicatedMergeTree.cpp:2349: DB::StorageReplicatedMergeTree::executeLogEntry(DB::ReplicatedMergeTreeLogEntry&) @ 0x0000000015eba91b 20. /build/src/Storages/StorageReplicatedMergeTree.cpp:3876: bool std::__function::__policy_invoker&)>::__call_impl[abi:se190107])::$_1, bool (std::shared_ptr&)>>(std::__function::__policy_storage const*, std::shared_ptr&) @ 0x0000000015f9837e 21. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000165d6fc3 22. /build/src/Storages/StorageReplicatedMergeTree.cpp:3872: DB::StorageReplicatedMergeTree::processQueueEntry(std::shared_ptr) @ 0x0000000015efc18a 23. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001624c1b2 24. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000162f9c70 25. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x00000000162fa55a 26. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc6653 27. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000000fccc4c3 28. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc3d92 29. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fcca080 30. ? @ 0x00007fbc6213eac3 31. ? @ 0x00007fbc621d0850 (version 25.3.6.10636.altinitytest (altinity build)) 2025.07.28 11:52:25.435653 [ 5112 ] {fad34803-069f-4917-a1c9-27c8891ef484} executeQuery: Code: 159. DB::Exception: Timeout exceeded: elapsed 2079.244459 ms, maximum: 2000 ms. (TIMEOUT_EXCEEDED) (version 25.3.6.10636.altinitytest (altinity build)) (from [::1]:58532) (comment: 02896_max_execution_time_with_break_overflow_mode.sql) (query 4, line 11) (in query: -- Query returns timeout error before its full execution time is estimated SELECT * FROM numbers(100000000) SETTINGS max_block_size=1, timeout_before_checking_execution_speed=1, max_execution_time=2, timeout_overflow_mode='throw' FORMAT Null;), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, double&&, long&&) @ 0x0000000013bb358b 4. /build/src/QueryPipeline/ExecutionSpeedLimits.cpp:113: DB::ExecutionSpeedLimits::checkTimeLimit(unsigned long const&, DB::OverflowMode) const @ 0x0000000013bb28cc 5. /build/src/Interpreters/ProcessList.cpp:559: DB::QueryStatus::checkTimeLimit() @ 0x0000000014a4c2df 6. /build/src/Processors/Executors/PipelineExecutor.cpp:206: DB::PipelineExecutor::finalizeExecution() @ 0x00000000169b13ba 7. /build/src/Processors/Executors/PipelineExecutor.cpp:153: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x00000000169b0584 8. /build/src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:se190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169bfeab 9. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc3d92 10. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fcca080 11. ? @ 0x00007fbc6213eac3 12. ? @ 0x00007fbc621d0850 2025.07.28 11:52:25.445755 [ 5112 ] {} TCPHandler: Code: 159. DB::Exception: Timeout exceeded: elapsed 2079.244459 ms, maximum: 2000 ms. (TIMEOUT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, double&&, long&&) @ 0x0000000013bb358b 4. /build/src/QueryPipeline/ExecutionSpeedLimits.cpp:113: DB::ExecutionSpeedLimits::checkTimeLimit(unsigned long const&, DB::OverflowMode) const @ 0x0000000013bb28cc 5. /build/src/Interpreters/ProcessList.cpp:559: DB::QueryStatus::checkTimeLimit() @ 0x0000000014a4c2df 6. /build/src/Processors/Executors/PipelineExecutor.cpp:206: DB::PipelineExecutor::finalizeExecution() @ 0x00000000169b13ba 7. /build/src/Processors/Executors/PipelineExecutor.cpp:153: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x00000000169b0584 8. /build/src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:se190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169bfeab 9. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc3d92 10. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fcca080 11. ? @ 0x00007fbc6213eac3 12. ? @ 0x00007fbc621d0850 Job's origin stack trace: 0. /build/src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000000fc33b84 1. /build/src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000000fcc2ea7 2. /build/src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fcc535c 3. /build/src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000000fcc584d 4. /build/src/Common/ThreadPool.h:279: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x00000000169bf193 5. /build/src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x00000000169bf518 6. /build/src/Server/TCPHandler.cpp:1237: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x00000000168f1525 7. /build/src/Server/TCPHandler.cpp:678: DB::TCPHandler::runImpl() @ 0x00000000168e68e5 8. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 9. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 10. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 11. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 12. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 13. ? @ 0x00007fbc6213eac3 14. ? @ 0x00007fbc621d0850 2025.07.28 11:52:25.476332 [ 17208 ] {} 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. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x000000000c25bc4b 4. /build/src/Access/SettingsConstraints.cpp:343: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000138596e3 5. /build/src/Access/SettingsConstraints.cpp:300: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000013858faf 6. /build/src/Access/SettingsConstraints.cpp:209: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x00000000138592b8 7. /build/src/Interpreters/Context.cpp:2690: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000014436134 8. /build/src/Interpreters/Context.cpp:2729: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x000000001443662b 9. /build/src/Server/TCPHandler.cpp:2158: DB::TCPHandler::processQuery(std::optional&) @ 0x00000000168f61df 10. /build/src/Server/TCPHandler.cpp:918: DB::TCPHandler::receivePacketsExpectQuery(std::optional&) @ 0x00000000168ef965 11. /build/src/Server/TCPHandler.cpp:491: DB::TCPHandler::runImpl() @ 0x00000000168e5eb4 12. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 13. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 14. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 16. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 17. ? @ 0x00007fbc6213eac3 18. ? @ 0x00007fbc621d0850 2025.07.28 11:52:25.504911 [ 17208 ] {} 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. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000000a074fcb 4. /build/src/Server/TCPHandler.cpp:897: DB::TCPHandler::receivePacketsExpectQuery(std::optional&) @ 0x00000000168efa89 5. /build/src/Server/TCPHandler.cpp:491: DB::TCPHandler::runImpl() @ 0x00000000168e5eb4 6. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 7. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 8. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 9. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 10. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 11. ? @ 0x00007fbc6213eac3 12. ? @ 0x00007fbc621d0850 2025.07.28 11:52:25.862303 [ 11851 ] {eeb6f273-89d2-4335-8dd6-e515116e46ef} executeQuery: Code: 36. DB::Exception: Tables have different secondary indices. (BAD_ARGUMENTS) (version 25.3.6.10636.altinitytest (altinity build)) (from [::1]:57418) (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. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000000a074fcb 4. /build/src/Storages/MergeTree/MergeTreeData.cpp:7752: DB::MergeTreeData::checkStructureAndGetMergeTreeData(DB::IStorage&, std::shared_ptr const&, std::shared_ptr const&) const @ 0x00000000163726fc 5. /build/src/Storages/StorageMergeTree.cpp:2253: DB::StorageMergeTree::replacePartitionFrom(std::shared_ptr const&, std::shared_ptr const&, bool, std::shared_ptr) @ 0x0000000016656b6b 6. /build/src/Storages/MergeTree/MergeTreeData.cpp:5752: DB::MergeTreeData::alterPartition(std::shared_ptr const&, std::vector> const&, std::shared_ptr) @ 0x00000000163580cd 7. /build/src/Interpreters/InterpreterAlterQuery.cpp:242: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x00000000148def37 8. /build/src/Interpreters/InterpreterAlterQuery.cpp:77: DB::InterpreterAlterQuery::execute() @ 0x00000000148dcb0d 9. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88dc9 10. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 11. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 12. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 13. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 14. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 16. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 17. ? @ 0x00007fbc6213eac3 18. ? @ 0x00007fbc621d0850 2025.07.28 11:52:25.880401 [ 11851 ] {} TCPHandler: Code: 36. DB::Exception: Tables have different secondary indices. (BAD_ARGUMENTS), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000000a074fcb 4. /build/src/Storages/MergeTree/MergeTreeData.cpp:7752: DB::MergeTreeData::checkStructureAndGetMergeTreeData(DB::IStorage&, std::shared_ptr const&, std::shared_ptr const&) const @ 0x00000000163726fc 5. /build/src/Storages/StorageMergeTree.cpp:2253: DB::StorageMergeTree::replacePartitionFrom(std::shared_ptr const&, std::shared_ptr const&, bool, std::shared_ptr) @ 0x0000000016656b6b 6. /build/src/Storages/MergeTree/MergeTreeData.cpp:5752: DB::MergeTreeData::alterPartition(std::shared_ptr const&, std::vector> const&, std::shared_ptr) @ 0x00000000163580cd 7. /build/src/Interpreters/InterpreterAlterQuery.cpp:242: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x00000000148def37 8. /build/src/Interpreters/InterpreterAlterQuery.cpp:77: DB::InterpreterAlterQuery::execute() @ 0x00000000148dcb0d 9. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88dc9 10. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 11. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 12. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 13. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 14. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 16. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 17. ? @ 0x00007fbc6213eac3 18. ? @ 0x00007fbc621d0850 2025.07.28 11:52:25.952131 [ 3966 ] {} test_13.rmt2 (7f9b740d-015c-470e-8cc6-8ba33be0dc63): auto DB::StorageReplicatedMergeTree::processQueueEntry(ReplicatedMergeTreeQueue::SelectedEntryPtr)::(anonymous class)::operator()(LogEntryPtr &) const: Code: 86. DB::HTTPException: Received error from remote server http://146b4357c08d:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Ftest%2F01165%2Ftest_13%2Frmt%2Freplicas%2F1&part=20250728_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.6.10636.altinitytest (altinity build)) '. (RECEIVED_ERROR_FROM_REMOTE_IO_SERVER), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.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 const&, int&&, String const&, unsigned long&&, String const&) @ 0x000000000feda8d9 4. /build/src/IO/HTTPCommon.cpp:104: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x000000000feda6e2 5. /build/src/IO/HTTPCommon.cpp:93: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x000000000feda537 6. /build/src/IO/ReadWriteBufferFromHTTP.cpp:277: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x000000001184a4c4 7. /build/src/IO/ReadWriteBufferFromHTTP.cpp:285: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x000000001184a615 8. /build/src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x000000001184ae59 9. /build/src/IO/ReadWriteBufferFromHTTP.cpp:472: void std::__function::__policy_invoker::__call_impl[abi:se190107]>(std::__function::__policy_storage const*) @ 0x000000001184cedd 10. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001184858b 11. /build/src/IO/ReadWriteBufferFromHTTP.cpp:465: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x000000001184bf0b 12. /build/src/IO/ReadBuffer.h:60: DB::ReadBuffer::next() @ 0x000000000a148c7b 13. /build/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) @ 0x0000000011849fb2 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]>&)>&, 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&) @ 0x0000000011841980 15. /build/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) @ 0x000000001621208e 16. /build/src/Storages/StorageReplicatedMergeTree.cpp:5228: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl[abi:se190107] const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000015f9a5fe 17. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000015ed8bfd 18. /build/src/Storages/StorageReplicatedMergeTree.cpp:2514: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x0000000015ec9aab 19. /build/src/Storages/StorageReplicatedMergeTree.cpp:2349: DB::StorageReplicatedMergeTree::executeLogEntry(DB::ReplicatedMergeTreeLogEntry&) @ 0x0000000015eba91b 20. /build/src/Storages/StorageReplicatedMergeTree.cpp:3876: bool std::__function::__policy_invoker&)>::__call_impl[abi:se190107])::$_1, bool (std::shared_ptr&)>>(std::__function::__policy_storage const*, std::shared_ptr&) @ 0x0000000015f9837e 21. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000165d6fc3 22. /build/src/Storages/StorageReplicatedMergeTree.cpp:3872: DB::StorageReplicatedMergeTree::processQueueEntry(std::shared_ptr) @ 0x0000000015efc18a 23. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001624c1b2 24. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000162f9c70 25. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x00000000162fa55a 26. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc6653 27. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000000fccc4c3 28. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc3d92 29. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fcca080 30. ? @ 0x00007fbc6213eac3 31. ? @ 0x00007fbc621d0850 (version 25.3.6.10636.altinitytest (altinity build)) 2025.07.28 11:52:26.527794 [ 17251 ] {86ea9f10-c09d-4e89-89c4-484bdd3dd0c9} executeQuery: Code: 56. DB::Exception: Unknown table engine s3. (UNKNOWN_STORAGE) (version 25.3.6.10636.altinitytest (altinity build)) (from [::1]:58016) (comment: 03036_reading_s3_archives.sql) (query 18, line 21) (in query: CREATE table table_noexist Engine s3(s3_conn, filename='03036_archive2.zip :: nonexistent.csv');), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000a9b78ab 4. /build/src/Storages/StorageFactory.cpp:278: DB::StorageFactory::getStorageFeatures(String const&) const @ 0x0000000015d8367b 5. /build/src/Interpreters/InterpreterCreateQuery.cpp:990: DB::InterpreterCreateQuery::getTablePropertiesAndNormalizeCreateQuery(DB::ASTCreateQuery&, DB::LoadingStrictnessLevel) const @ 0x00000000148f0c98 6. /build/src/Interpreters/InterpreterCreateQuery.cpp:1657: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000148f901b 7. /build/src/Interpreters/InterpreterCreateQuery.cpp:2352: DB::InterpreterCreateQuery::execute() @ 0x0000000014905a41 8. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88dc9 9. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 10. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 11. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 12. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 13. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 14. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 15. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 16. ? @ 0x00007fbc6213eac3 17. ? @ 0x00007fbc621d0850 2025.07.28 11:52:26.552333 [ 17251 ] {} TCPHandler: Code: 56. DB::Exception: Unknown table engine s3. (UNKNOWN_STORAGE), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000a9b78ab 4. /build/src/Storages/StorageFactory.cpp:278: DB::StorageFactory::getStorageFeatures(String const&) const @ 0x0000000015d8367b 5. /build/src/Interpreters/InterpreterCreateQuery.cpp:990: DB::InterpreterCreateQuery::getTablePropertiesAndNormalizeCreateQuery(DB::ASTCreateQuery&, DB::LoadingStrictnessLevel) const @ 0x00000000148f0c98 6. /build/src/Interpreters/InterpreterCreateQuery.cpp:1657: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000148f901b 7. /build/src/Interpreters/InterpreterCreateQuery.cpp:2352: DB::InterpreterCreateQuery::execute() @ 0x0000000014905a41 8. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88dc9 9. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 10. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 11. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 12. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 13. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 14. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 15. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 16. ? @ 0x00007fbc6213eac3 17. ? @ 0x00007fbc621d0850 2025.07.28 11:52:26.688102 [ 11851 ] {2144e968-5352-4285-9c4f-4fbd23b19855} executeQuery: Code: 36. DB::Exception: Tables have different projections. (BAD_ARGUMENTS) (version 25.3.6.10636.altinitytest (altinity build)) (from [::1]:57418) (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. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000000a074fcb 4. /build/src/Storages/MergeTree/MergeTreeData.cpp:7755: DB::MergeTreeData::checkStructureAndGetMergeTreeData(DB::IStorage&, std::shared_ptr const&, std::shared_ptr const&) const @ 0x000000001637276b 5. /build/src/Storages/StorageMergeTree.cpp:2253: DB::StorageMergeTree::replacePartitionFrom(std::shared_ptr const&, std::shared_ptr const&, bool, std::shared_ptr) @ 0x0000000016656b6b 6. /build/src/Storages/MergeTree/MergeTreeData.cpp:5752: DB::MergeTreeData::alterPartition(std::shared_ptr const&, std::vector> const&, std::shared_ptr) @ 0x00000000163580cd 7. /build/src/Interpreters/InterpreterAlterQuery.cpp:242: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x00000000148def37 8. /build/src/Interpreters/InterpreterAlterQuery.cpp:77: DB::InterpreterAlterQuery::execute() @ 0x00000000148dcb0d 9. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88dc9 10. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 11. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 12. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 13. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 14. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 16. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 17. ? @ 0x00007fbc6213eac3 18. ? @ 0x00007fbc621d0850 2025.07.28 11:52:26.702458 [ 11851 ] {} TCPHandler: Code: 36. DB::Exception: Tables have different projections. (BAD_ARGUMENTS), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000000a074fcb 4. /build/src/Storages/MergeTree/MergeTreeData.cpp:7755: DB::MergeTreeData::checkStructureAndGetMergeTreeData(DB::IStorage&, std::shared_ptr const&, std::shared_ptr const&) const @ 0x000000001637276b 5. /build/src/Storages/StorageMergeTree.cpp:2253: DB::StorageMergeTree::replacePartitionFrom(std::shared_ptr const&, std::shared_ptr const&, bool, std::shared_ptr) @ 0x0000000016656b6b 6. /build/src/Storages/MergeTree/MergeTreeData.cpp:5752: DB::MergeTreeData::alterPartition(std::shared_ptr const&, std::vector> const&, std::shared_ptr) @ 0x00000000163580cd 7. /build/src/Interpreters/InterpreterAlterQuery.cpp:242: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x00000000148def37 8. /build/src/Interpreters/InterpreterAlterQuery.cpp:77: DB::InterpreterAlterQuery::execute() @ 0x00000000148dcb0d 9. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88dc9 10. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 11. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 12. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 13. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 14. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 16. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 17. ? @ 0x00007fbc6213eac3 18. ? @ 0x00007fbc621d0850 2025.07.28 11:52:26.768465 [ 17270 ] {} InterserverIOHTTPHandler: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=9, jobs=0). (CANNOT_SCHEDULE_TASK), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000fccaeeb 4. /build/src/Common/ThreadPool.cpp:275: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000fccc813 5. /build/src/Common/ThreadPool.cpp:323: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fcc7bbc 6. /build/src/Common/ThreadPool.cpp:494: ThreadPoolImpl>::scheduleOrThrowOnError(std::function, Priority) @ 0x000000000fcc7a0e 7. /build/src/Common/threadPoolCallbackRunner.h:52: std::function (std::function&&, Priority)> DB::threadPoolCallbackRunnerUnsafe>(ThreadPoolImpl>&, String const&)::'lambda'(std::function&&, Priority)::operator()(std::function&&, Priority) @ 0x000000001320131a 8. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: std::future std::__function::__policy_invoker (std::function&&, Priority)>::__call_impl[abi:se190107] (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&&) @ 0x000000001320110f 9. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000132002ce 10. /build/src/IO/AsynchronousReadBufferFromFileDescriptor.cpp:62: DB::AsynchronousReadBufferFromFileDescriptor::asyncReadInto(char*, unsigned long, Priority) @ 0x00000000131f77d0 11. /build/src/IO/AsynchronousReadBufferFromFileDescriptor.cpp:100: DB::AsynchronousReadBufferFromFileDescriptor::nextImpl() @ 0x00000000131f7acb 12. /build/src/IO/ReadBuffer.h:60: DB::ReadBuffer::next() @ 0x000000000a148c7b 13. /build/src/IO/ReadBuffer.h:96: DB::(anonymous namespace)::copyDataImpl(DB::ReadBuffer&, DB::WriteBuffer&, bool, unsigned long, std::function, std::shared_ptr) @ 0x000000000fc8ec67 14. /build/src/IO/copyData.cpp:114: DB::copyDataWithThrottler(DB::ReadBuffer&, DB::WriteBuffer&, std::function, std::shared_ptr) @ 0x000000000fc8f186 15. /build/src/Storages/MergeTree/DataPartsExchange.cpp:320: DB::DataPartsExchange::Service::sendPartFromDisk(std::shared_ptr const&, DB::WriteBuffer&, int, bool, bool) @ 0x000000001620df69 16. /build/src/Storages/MergeTree/DataPartsExchange.cpp:224: DB::DataPartsExchange::Service::processQuery(DB::HTMLForm const&, DB::ReadBuffer&, DB::WriteBuffer&, DB::HTTPServerResponse&) @ 0x000000001620c6f1 17. /build/src/Server/InterserverIOHTTPHandler.cpp:80: DB::InterserverIOHTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTTPServerResponse&, std::shared_ptr) @ 0x0000000016881c9f 18. /build/src/Server/InterserverIOHTTPHandler.cpp:101: DB::InterserverIOHTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x00000000168822ce 19. /build/src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x0000000016907e99 20. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 21. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 22. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 23. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 24. ? @ 0x00007fbc6213eac3 25. ? @ 0x00007fbc621d0850 (version 25.3.6.10636.altinitytest (altinity build)) 2025.07.28 11:52:26.889795 [ 3974 ] {} test_13.alter_table1 (b6d50f9f-3cd1-4fee-aa3e-84cf679f8083): auto DB::StorageReplicatedMergeTree::processQueueEntry(ReplicatedMergeTreeQueue::SelectedEntryPtr)::(anonymous class)::operator()(LogEntryPtr &) const: Poco::Exception. Code: 1000, e.code() = 0, Malformed message: Unexpected EOF, Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::IOException::IOException(String const&, int) @ 0x000000001abd0b92 1. /build/base/poco/Net/src/NetException.cpp:26: Poco::Net::MessageException::MessageException(String const&, int) @ 0x000000001ac57709 2. /build/base/poco/Net/src/HTTPChunkedStream.cpp:64: Poco::Net::HTTPChunkedStreamBuf::parseChunkLen() @ 0x000000001ac328cc 3. /build/base/poco/Net/src/HTTPChunkedStream.cpp:116: Poco::Net::HTTPChunkedStreamBuf::readFromDevice(char*, long) @ 0x000000001ac32bb3 4. /build/src/IO/ReadBufferFromIStream.cpp:27: DB::ReadBufferFromIStream::nextImpl() @ 0x000000001184fb7b 5. /build/src/IO/ReadBuffer.h:60: DB::ReadBuffer::next() @ 0x000000000a148c7b 6. /build/src/IO/ReadWriteBufferFromHTTP.cpp:505: void std::__function::__policy_invoker::__call_impl[abi:se190107]>(std::__function::__policy_storage const*) @ 0x000000001184cf9d 7. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001184858b 8. /build/src/IO/ReadWriteBufferFromHTTP.cpp:465: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x000000001184bf0b 9. /build/src/IO/ReadBuffer.h:60: DB::ReadBuffer::next() @ 0x000000000a148c7b 10. /build/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) @ 0x0000000011849fb2 11. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]>&)>&, 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&) @ 0x0000000011841980 12. /build/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) @ 0x000000001621208e 13. /build/src/Storages/StorageReplicatedMergeTree.cpp:5228: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl[abi:se190107] const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000015f9a5fe 14. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000015ed8bfd 15. /build/src/Storages/StorageReplicatedMergeTree.cpp:2514: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x0000000015ec9aab 16. /build/src/Storages/StorageReplicatedMergeTree.cpp:2349: DB::StorageReplicatedMergeTree::executeLogEntry(DB::ReplicatedMergeTreeLogEntry&) @ 0x0000000015eba91b 17. /build/src/Storages/StorageReplicatedMergeTree.cpp:3876: bool std::__function::__policy_invoker&)>::__call_impl[abi:se190107])::$_1, bool (std::shared_ptr&)>>(std::__function::__policy_storage const*, std::shared_ptr&) @ 0x0000000015f9837e 18. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000165d6fc3 19. /build/src/Storages/StorageReplicatedMergeTree.cpp:3872: DB::StorageReplicatedMergeTree::processQueueEntry(std::shared_ptr) @ 0x0000000015efc18a 20. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001624c1b2 21. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000162f9c70 22. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x00000000162fa55a 23. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc6653 24. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000000fccc4c3 25. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc3d92 26. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fcca080 27. ? @ 0x00007fbc6213eac3 28. ? @ 0x00007fbc621d0850 (version 25.3.6.10636.altinitytest (altinity build)) 2025.07.28 11:52:27.126372 [ 3960 ] {} test_13.rmt2 (7f9b740d-015c-470e-8cc6-8ba33be0dc63): auto DB::StorageReplicatedMergeTree::processQueueEntry(ReplicatedMergeTreeQueue::SelectedEntryPtr)::(anonymous class)::operator()(LogEntryPtr &) const: Code: 86. DB::HTTPException: Received error from remote server http://146b4357c08d:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Ftest%2F01165%2Ftest_13%2Frmt%2Freplicas%2F1&part=20250728_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.6.10636.altinitytest (altinity build)) '. (RECEIVED_ERROR_FROM_REMOTE_IO_SERVER), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.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 const&, int&&, String const&, unsigned long&&, String const&) @ 0x000000000feda8d9 4. /build/src/IO/HTTPCommon.cpp:104: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x000000000feda6e2 5. /build/src/IO/HTTPCommon.cpp:93: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x000000000feda537 6. /build/src/IO/ReadWriteBufferFromHTTP.cpp:277: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x000000001184a4c4 7. /build/src/IO/ReadWriteBufferFromHTTP.cpp:285: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x000000001184a615 8. /build/src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x000000001184ae59 9. /build/src/IO/ReadWriteBufferFromHTTP.cpp:472: void std::__function::__policy_invoker::__call_impl[abi:se190107]>(std::__function::__policy_storage const*) @ 0x000000001184cedd 10. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001184858b 11. /build/src/IO/ReadWriteBufferFromHTTP.cpp:465: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x000000001184bf0b 12. /build/src/IO/ReadBuffer.h:60: DB::ReadBuffer::next() @ 0x000000000a148c7b 13. /build/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) @ 0x0000000011849fb2 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]>&)>&, 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&) @ 0x0000000011841980 15. /build/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) @ 0x000000001621208e 16. /build/src/Storages/StorageReplicatedMergeTree.cpp:5228: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl[abi:se190107] const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000015f9a5fe 17. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000015ed8bfd 18. /build/src/Storages/StorageReplicatedMergeTree.cpp:2514: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x0000000015ec9aab 19. /build/src/Storages/StorageReplicatedMergeTree.cpp:2349: DB::StorageReplicatedMergeTree::executeLogEntry(DB::ReplicatedMergeTreeLogEntry&) @ 0x0000000015eba91b 20. /build/src/Storages/StorageReplicatedMergeTree.cpp:3876: bool std::__function::__policy_invoker&)>::__call_impl[abi:se190107])::$_1, bool (std::shared_ptr&)>>(std::__function::__policy_storage const*, std::shared_ptr&) @ 0x0000000015f9837e 21. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000165d6fc3 22. /build/src/Storages/StorageReplicatedMergeTree.cpp:3872: DB::StorageReplicatedMergeTree::processQueueEntry(std::shared_ptr) @ 0x0000000015efc18a 23. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001624c1b2 24. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000162f9c70 25. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x00000000162fa55a 26. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc6653 27. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000000fccc4c3 28. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc3d92 29. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fcca080 30. ? @ 0x00007fbc6213eac3 31. ? @ 0x00007fbc621d0850 (version 25.3.6.10636.altinitytest (altinity build)) 2025.07.28 11:52:27.564474 [ 17207 ] {843f77fd-10c6-418e-aec8-086925dc7938} PushingToViews: Failed to push block to view test_5.v1 (4ae2feef-b6fa-47ac-b20c-744da14b2a0a), Stack size too large. Stack address: 0x7fb7fddf0000, frame address: 0x7fb7fe1ef100, stack size: 4198144, maximum stack size: 8388608 2025.07.28 11:52:27.571076 [ 17207 ] {843f77fd-10c6-418e-aec8-086925dc7938} PushingToViews: Failed to push block to view test_5.v2 (7c22a887-3ed3-40f1-a092-d92463e4b87b), Stack size too large. Stack address: 0x7fb7fddf0000, frame address: 0x7fb7fe1ef100, stack size: 4198144, maximum stack size: 8388608 2025.07.28 11:52:27.572159 [ 17207 ] {843f77fd-10c6-418e-aec8-086925dc7938} PushingToViews: Failed to push block to view test_5.v1 (4ae2feef-b6fa-47ac-b20c-744da14b2a0a), Stack size too large. Stack address: 0x7fb7fddf0000, frame address: 0x7fb7fe1ef100, stack size: 4198144, maximum stack size: 8388608 2025.07.28 11:52:27.573121 [ 17207 ] {843f77fd-10c6-418e-aec8-086925dc7938} PushingToViews: Failed to push block to view test_5.v2 (7c22a887-3ed3-40f1-a092-d92463e4b87b), Stack size too large. Stack address: 0x7fb7fddf0000, frame address: 0x7fb7fe1ef100, stack size: 4198144, maximum stack size: 8388608 2025.07.28 11:52:27.574282 [ 17207 ] {843f77fd-10c6-418e-aec8-086925dc7938} PushingToViews: Failed to push block to view test_5.v1 (4ae2feef-b6fa-47ac-b20c-744da14b2a0a), Stack size too large. Stack address: 0x7fb7fddf0000, frame address: 0x7fb7fe1ef100, stack size: 4198144, maximum stack size: 8388608 2025.07.28 11:52:27.576226 [ 17207 ] {843f77fd-10c6-418e-aec8-086925dc7938} PushingToViews: Failed to push block to view test_5.v2 (7c22a887-3ed3-40f1-a092-d92463e4b87b), Stack size too large. Stack address: 0x7fb7fddf0000, frame address: 0x7fb7fe1ef100, stack size: 4198144, maximum stack size: 8388608 2025.07.28 11:52:27.597208 [ 17207 ] {843f77fd-10c6-418e-aec8-086925dc7938} PushingToViews: Failed to push block to view test_5.v1 (4ae2feef-b6fa-47ac-b20c-744da14b2a0a), Stack size too large. Stack address: 0x7fb7fddf0000, frame address: 0x7fb7fe1ef100, stack size: 4198144, maximum stack size: 8388608 2025.07.28 11:52:27.598795 [ 17207 ] {843f77fd-10c6-418e-aec8-086925dc7938} PushingToViews: Failed to push block to view test_5.v2 (7c22a887-3ed3-40f1-a092-d92463e4b87b), Stack size too large. Stack address: 0x7fb7fddf0000, frame address: 0x7fb7fe1ef100, stack size: 4198144, maximum stack size: 8388608 2025.07.28 11:52:27.600812 [ 17207 ] {843f77fd-10c6-418e-aec8-086925dc7938} PushingToViews: Failed to push block to view test_5.v1 (4ae2feef-b6fa-47ac-b20c-744da14b2a0a), Stack size too large. Stack address: 0x7fb7fddf0000, frame address: 0x7fb7fe1ef100, stack size: 4198144, maximum stack size: 8388608 2025.07.28 11:52:27.613744 [ 17207 ] {843f77fd-10c6-418e-aec8-086925dc7938} PushingToViews: Failed to push block to view test_5.v2 (7c22a887-3ed3-40f1-a092-d92463e4b87b), Stack size too large. Stack address: 0x7fb7fddf0000, frame address: 0x7fb7fe1ef100, stack size: 4198144, maximum stack size: 8388608 2025.07.28 11:52:27.616133 [ 17207 ] {843f77fd-10c6-418e-aec8-086925dc7938} PushingToViews: Failed to push block to view test_5.v1 (4ae2feef-b6fa-47ac-b20c-744da14b2a0a), Stack size too large. Stack address: 0x7fb7fddf0000, frame address: 0x7fb7fe1ef100, stack size: 4198144, maximum stack size: 8388608 2025.07.28 11:52:27.617774 [ 17207 ] {843f77fd-10c6-418e-aec8-086925dc7938} PushingToViews: Failed to push block to view test_5.v2 (7c22a887-3ed3-40f1-a092-d92463e4b87b), Stack size too large. Stack address: 0x7fb7fddf0000, frame address: 0x7fb7fe1ef100, stack size: 4198144, maximum stack size: 8388608 2025.07.28 11:52:27.619803 [ 17207 ] {843f77fd-10c6-418e-aec8-086925dc7938} PushingToViews: Failed to push block to view test_5.v1 (4ae2feef-b6fa-47ac-b20c-744da14b2a0a), Stack size too large. Stack address: 0x7fb7fddf0000, frame address: 0x7fb7fe1ef100, stack size: 4198144, maximum stack size: 8388608 2025.07.28 11:52:27.622058 [ 17207 ] {843f77fd-10c6-418e-aec8-086925dc7938} PushingToViews: Failed to push block to view test_5.v2 (7c22a887-3ed3-40f1-a092-d92463e4b87b), Stack size too large. Stack address: 0x7fb7fddf0000, frame address: 0x7fb7fe1ef100, stack size: 4198144, maximum stack size: 8388608 2025.07.28 11:52:27.635787 [ 17207 ] {843f77fd-10c6-418e-aec8-086925dc7938} PushingToViews: Failed to push block to view test_5.v1 (4ae2feef-b6fa-47ac-b20c-744da14b2a0a), Stack size too large. Stack address: 0x7fb7fddf0000, frame address: 0x7fb7fe1ef100, stack size: 4198144, maximum stack size: 8388608 2025.07.28 11:52:27.637904 [ 17207 ] {843f77fd-10c6-418e-aec8-086925dc7938} PushingToViews: Failed to push block to view test_5.v2 (7c22a887-3ed3-40f1-a092-d92463e4b87b), Stack size too large. Stack address: 0x7fb7fddf0000, frame address: 0x7fb7fe1ef100, stack size: 4198144, maximum stack size: 8388608 2025.07.28 11:52:27.644985 [ 17207 ] {843f77fd-10c6-418e-aec8-086925dc7938} PushingToViews: Failed to push block to view test_5.v1 (4ae2feef-b6fa-47ac-b20c-744da14b2a0a), Stack size too large. Stack address: 0x7fb7fddf0000, frame address: 0x7fb7fe1ef100, stack size: 4198144, maximum stack size: 8388608 2025.07.28 11:52:27.646844 [ 17207 ] {843f77fd-10c6-418e-aec8-086925dc7938} PushingToViews: Failed to push block to view test_5.v2 (7c22a887-3ed3-40f1-a092-d92463e4b87b), Stack size too large. Stack address: 0x7fb7fddf0000, frame address: 0x7fb7fe1ef100, stack size: 4198144, maximum stack size: 8388608 2025.07.28 11:52:27.654768 [ 17207 ] {843f77fd-10c6-418e-aec8-086925dc7938} PushingToViews: Failed to push block to view test_5.v1 (4ae2feef-b6fa-47ac-b20c-744da14b2a0a), Stack size too large. Stack address: 0x7fb7fddf0000, frame address: 0x7fb7fe1ef100, stack size: 4198144, maximum stack size: 8388608 2025.07.28 11:52:27.654978 [ 3967 ] {} test_13.rmt2 (7f9b740d-015c-470e-8cc6-8ba33be0dc63): auto DB::StorageReplicatedMergeTree::processQueueEntry(ReplicatedMergeTreeQueue::SelectedEntryPtr)::(anonymous class)::operator()(LogEntryPtr &) const: Code: 86. DB::HTTPException: Received error from remote server http://146b4357c08d:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Ftest%2F01165%2Ftest_13%2Frmt%2Freplicas%2F1&part=20250728_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.6.10636.altinitytest (altinity build)) '. (RECEIVED_ERROR_FROM_REMOTE_IO_SERVER), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.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 const&, int&&, String const&, unsigned long&&, String const&) @ 0x000000000feda8d9 4. /build/src/IO/HTTPCommon.cpp:104: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x000000000feda6e2 5. /build/src/IO/HTTPCommon.cpp:93: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x000000000feda537 6. /build/src/IO/ReadWriteBufferFromHTTP.cpp:277: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x000000001184a4c4 7. /build/src/IO/ReadWriteBufferFromHTTP.cpp:285: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x000000001184a615 8. /build/src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x000000001184ae59 9. /build/src/IO/ReadWriteBufferFromHTTP.cpp:472: void std::__function::__policy_invoker::__call_impl[abi:se190107]>(std::__function::__policy_storage const*) @ 0x000000001184cedd 10. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001184858b 11. /build/src/IO/ReadWriteBufferFromHTTP.cpp:465: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x000000001184bf0b 12. /build/src/IO/ReadBuffer.h:60: DB::ReadBuffer::next() @ 0x000000000a148c7b 13. /build/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) @ 0x0000000011849fb2 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]>&)>&, 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&) @ 0x0000000011841980 15. /build/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) @ 0x000000001621208e 16. /build/src/Storages/StorageReplicatedMergeTree.cpp:5228: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl[abi:se190107] const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000015f9a5fe 17. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000015ed8bfd 18. /build/src/Storages/StorageReplicatedMergeTree.cpp:2514: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x0000000015ec9aab 19. /build/src/Storages/StorageReplicatedMergeTree.cpp:2349: DB::StorageReplicatedMergeTree::executeLogEntry(DB::ReplicatedMergeTreeLogEntry&) @ 0x0000000015eba91b 20. /build/src/Storages/StorageReplicatedMergeTree.cpp:3876: bool std::__function::__policy_invoker&)>::__call_impl[abi:se190107])::$_1, bool (std::shared_ptr&)>>(std::__function::__policy_storage const*, std::shared_ptr&) @ 0x0000000015f9837e 21. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000165d6fc3 22. /build/src/Storages/StorageReplicatedMergeTree.cpp:3872: DB::StorageReplicatedMergeTree::processQueueEntry(std::shared_ptr) @ 0x0000000015efc18a 23. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001624c1b2 24. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000162f9c70 25. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x00000000162fa55a 26. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc6653 27. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000000fccc4c3 28. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc3d92 29. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fcca080 30. ? @ 0x00007fbc6213eac3 31. ? @ 0x00007fbc621d0850 (version 25.3.6.10636.altinitytest (altinity build)) 2025.07.28 11:52:27.659166 [ 17207 ] {843f77fd-10c6-418e-aec8-086925dc7938} PushingToViews: Failed to push block to view test_5.v2 (7c22a887-3ed3-40f1-a092-d92463e4b87b), Stack size too large. Stack address: 0x7fb7fddf0000, frame address: 0x7fb7fe1ef100, stack size: 4198144, maximum stack size: 8388608 2025.07.28 11:52:27.661923 [ 17207 ] {843f77fd-10c6-418e-aec8-086925dc7938} PushingToViews: Failed to push block to view test_5.v1 (4ae2feef-b6fa-47ac-b20c-744da14b2a0a), Stack size too large. Stack address: 0x7fb7fddf0000, frame address: 0x7fb7fe1ef100, stack size: 4198144, maximum stack size: 8388608 2025.07.28 11:52:27.669084 [ 17207 ] {843f77fd-10c6-418e-aec8-086925dc7938} PushingToViews: Failed to push block to view test_5.v2 (7c22a887-3ed3-40f1-a092-d92463e4b87b), Stack size too large. Stack address: 0x7fb7fddf0000, frame address: 0x7fb7fe1ef100, stack size: 4198144, maximum stack size: 8388608 2025.07.28 11:52:27.680750 [ 17207 ] {843f77fd-10c6-418e-aec8-086925dc7938} PushingToViews: Failed to push block to view test_5.v1 (4ae2feef-b6fa-47ac-b20c-744da14b2a0a), Stack size too large. Stack address: 0x7fb7fddf0000, frame address: 0x7fb7fe1ef100, stack size: 4198144, maximum stack size: 8388608 2025.07.28 11:52:27.690514 [ 17207 ] {843f77fd-10c6-418e-aec8-086925dc7938} PushingToViews: Failed to push block to view test_5.v2 (7c22a887-3ed3-40f1-a092-d92463e4b87b), Stack size too large. Stack address: 0x7fb7fddf0000, frame address: 0x7fb7fe1ef100, stack size: 4198144, maximum stack size: 8388608 2025.07.28 11:52:27.694277 [ 17207 ] {843f77fd-10c6-418e-aec8-086925dc7938} PushingToViews: Failed to push block to view test_5.v1 (4ae2feef-b6fa-47ac-b20c-744da14b2a0a), Stack size too large. Stack address: 0x7fb7fddf0000, frame address: 0x7fb7fe1ef100, stack size: 4198144, maximum stack size: 8388608 2025.07.28 11:52:27.704776 [ 17207 ] {843f77fd-10c6-418e-aec8-086925dc7938} PushingToViews: Failed to push block to view test_5.v2 (7c22a887-3ed3-40f1-a092-d92463e4b87b), Stack size too large. Stack address: 0x7fb7fddf0000, frame address: 0x7fb7fe1ef100, stack size: 4198144, maximum stack size: 8388608 2025.07.28 11:52:27.733416 [ 17207 ] {843f77fd-10c6-418e-aec8-086925dc7938} PushingToViews: Failed to push block to view test_5.v1 (4ae2feef-b6fa-47ac-b20c-744da14b2a0a), Stack size too large. Stack address: 0x7fb7fddf0000, frame address: 0x7fb7fe1ef100, stack size: 4198144, maximum stack size: 8388608 2025.07.28 11:52:27.735791 [ 17207 ] {843f77fd-10c6-418e-aec8-086925dc7938} PushingToViews: Failed to push block to view test_5.v2 (7c22a887-3ed3-40f1-a092-d92463e4b87b), Stack size too large. Stack address: 0x7fb7fddf0000, frame address: 0x7fb7fe1ef100, stack size: 4198144, maximum stack size: 8388608 2025.07.28 11:52:27.738941 [ 17207 ] {843f77fd-10c6-418e-aec8-086925dc7938} PushingToViews: Failed to push block to view test_5.v1 (4ae2feef-b6fa-47ac-b20c-744da14b2a0a), Stack size too large. Stack address: 0x7fb7fddf0000, frame address: 0x7fb7fe1ef100, stack size: 4198144, maximum stack size: 8388608 2025.07.28 11:52:27.743117 [ 17207 ] {843f77fd-10c6-418e-aec8-086925dc7938} PushingToViews: Failed to push block to view test_5.v2 (7c22a887-3ed3-40f1-a092-d92463e4b87b), Stack size too large. Stack address: 0x7fb7fddf0000, frame address: 0x7fb7fe1ef100, stack size: 4198144, maximum stack size: 8388608 2025.07.28 11:52:27.744530 [ 17207 ] {843f77fd-10c6-418e-aec8-086925dc7938} PushingToViews: Failed to push block to view test_5.v1 (4ae2feef-b6fa-47ac-b20c-744da14b2a0a), Stack size too large. Stack address: 0x7fb7fddf0000, frame address: 0x7fb7fe1ef100, stack size: 4198144, maximum stack size: 8388608 2025.07.28 11:52:27.748114 [ 17207 ] {843f77fd-10c6-418e-aec8-086925dc7938} PushingToViews: Failed to push block to view test_5.v2 (7c22a887-3ed3-40f1-a092-d92463e4b87b), Stack size too large. Stack address: 0x7fb7fddf0000, frame address: 0x7fb7fe1ef100, stack size: 4198144, maximum stack size: 8388608 2025.07.28 11:52:27.750391 [ 3961 ] {} test_13.alter_table1 (b6d50f9f-3cd1-4fee-aa3e-84cf679f8083): Part /var/lib/clickhouse/store/b6d/b6d50f9f-3cd1-4fee-aa3e-84cf679f8083/detached/all_70_70_0/ is broken and needs manual correction. Reason: Code: 226. DB::Exception: No columns.txt in part all_91_91_0, expected path store/b6d/b6d50f9f-3cd1-4fee-aa3e-84cf679f8083/detached/all_70_70_0/columns.txt on drive default. (NO_FILE_IN_DATA_PART), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, String&, String&&) @ 0x0000000012da2e0b 4. /build/src/Storages/MergeTree/IMergeTreeDataPart.cpp:1629: DB::IMergeTreeDataPart::loadColumns(bool) @ 0x000000001625bb62 5. /build/src/Storages/MergeTree/IMergeTreeDataPart.cpp:839: DB::IMergeTreeDataPart::loadColumnsChecksumsIndexes(bool, bool) @ 0x0000000016259f5b 6. /build/src/Storages/StorageReplicatedMergeTree.cpp:2237: DB::StorageReplicatedMergeTree::attachPartHelperFoundValidPart(DB::ReplicatedMergeTreeLogEntry const&) const @ 0x0000000015eb838f 7. /build/src/Storages/StorageReplicatedMergeTree.cpp:2309: DB::StorageReplicatedMergeTree::executeLogEntry(DB::ReplicatedMergeTreeLogEntry&) @ 0x0000000015eb969e 8. /build/src/Storages/StorageReplicatedMergeTree.cpp:3876: bool std::__function::__policy_invoker&)>::__call_impl[abi:se190107])::$_1, bool (std::shared_ptr&)>>(std::__function::__policy_storage const*, std::shared_ptr&) @ 0x0000000015f9837e 9. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000165d6fc3 10. /build/src/Storages/StorageReplicatedMergeTree.cpp:3872: DB::StorageReplicatedMergeTree::processQueueEntry(std::shared_ptr) @ 0x0000000015efc18a 11. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001624c1b2 12. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000162f9c70 13. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x00000000162fa55a 14. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc6653 15. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000000fccc4c3 16. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc3d92 17. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fcca080 18. ? @ 0x00007fbc6213eac3 19. ? @ 0x00007fbc621d0850 (version 25.3.6.10636.altinitytest (altinity build)) 2025.07.28 11:52:27.752161 [ 17207 ] {843f77fd-10c6-418e-aec8-086925dc7938} PushingToViews: Failed to push block to view test_5.v1 (4ae2feef-b6fa-47ac-b20c-744da14b2a0a), Stack size too large. Stack address: 0x7fb7fddf0000, frame address: 0x7fb7fe1ef100, stack size: 4198144, maximum stack size: 8388608 2025.07.28 11:52:27.757366 [ 17207 ] {843f77fd-10c6-418e-aec8-086925dc7938} PushingToViews: Failed to push block to view test_5.v2 (7c22a887-3ed3-40f1-a092-d92463e4b87b), Stack size too large. Stack address: 0x7fb7fddf0000, frame address: 0x7fb7fe1ef100, stack size: 4198144, maximum stack size: 8388608 2025.07.28 11:52:27.771817 [ 17207 ] {843f77fd-10c6-418e-aec8-086925dc7938} PushingToViews: Failed to push block to view test_5.v1 (4ae2feef-b6fa-47ac-b20c-744da14b2a0a), Stack size too large. Stack address: 0x7fb7fddf0000, frame address: 0x7fb7fe1ef100, stack size: 4198144, maximum stack size: 8388608 2025.07.28 11:52:27.782669 [ 3970 ] {} test_13.alter_table1 (b6d50f9f-3cd1-4fee-aa3e-84cf679f8083): Part /var/lib/clickhouse/store/b6d/b6d50f9f-3cd1-4fee-aa3e-84cf679f8083/detached/all_70_70_0/ is broken and needs manual correction. Reason: Code: 226. DB::Exception: No columns.txt in part all_89_89_0, expected path store/b6d/b6d50f9f-3cd1-4fee-aa3e-84cf679f8083/detached/all_70_70_0/columns.txt on drive default. (NO_FILE_IN_DATA_PART), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, String&, String&&) @ 0x0000000012da2e0b 4. /build/src/Storages/MergeTree/IMergeTreeDataPart.cpp:1629: DB::IMergeTreeDataPart::loadColumns(bool) @ 0x000000001625bb62 5. /build/src/Storages/MergeTree/IMergeTreeDataPart.cpp:839: DB::IMergeTreeDataPart::loadColumnsChecksumsIndexes(bool, bool) @ 0x0000000016259f5b 6. /build/src/Storages/StorageReplicatedMergeTree.cpp:2237: DB::StorageReplicatedMergeTree::attachPartHelperFoundValidPart(DB::ReplicatedMergeTreeLogEntry const&) const @ 0x0000000015eb838f 7. /build/src/Storages/StorageReplicatedMergeTree.cpp:2309: DB::StorageReplicatedMergeTree::executeLogEntry(DB::ReplicatedMergeTreeLogEntry&) @ 0x0000000015eb969e 8. /build/src/Storages/StorageReplicatedMergeTree.cpp:3876: bool std::__function::__policy_invoker&)>::__call_impl[abi:se190107])::$_1, bool (std::shared_ptr&)>>(std::__function::__policy_storage const*, std::shared_ptr&) @ 0x0000000015f9837e 9. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000165d6fc3 10. /build/src/Storages/StorageReplicatedMergeTree.cpp:3872: DB::StorageReplicatedMergeTree::processQueueEntry(std::shared_ptr) @ 0x0000000015efc18a 11. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001624c1b2 12. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000162f9c70 13. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x00000000162fa55a 14. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc6653 15. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000000fccc4c3 16. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc3d92 17. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fcca080 18. ? @ 0x00007fbc6213eac3 19. ? @ 0x00007fbc621d0850 (version 25.3.6.10636.altinitytest (altinity build)) 2025.07.28 11:52:27.818062 [ 17207 ] {843f77fd-10c6-418e-aec8-086925dc7938} PushingToViews: Failed to push block to view test_5.v2 (7c22a887-3ed3-40f1-a092-d92463e4b87b), Stack size too large. Stack address: 0x7fb7fddf0000, frame address: 0x7fb7fe1ef100, stack size: 4198144, maximum stack size: 8388608 2025.07.28 11:52:27.820237 [ 17207 ] {843f77fd-10c6-418e-aec8-086925dc7938} PushingToViews: Failed to push block to view test_5.v1 (4ae2feef-b6fa-47ac-b20c-744da14b2a0a), Stack size too large. Stack address: 0x7fb7fddf0000, frame address: 0x7fb7fe1ef100, stack size: 4198144, maximum stack size: 8388608 2025.07.28 11:52:27.822251 [ 17207 ] {843f77fd-10c6-418e-aec8-086925dc7938} PushingToViews: Failed to push block to view test_5.v2 (7c22a887-3ed3-40f1-a092-d92463e4b87b), Stack size too large. Stack address: 0x7fb7fddf0000, frame address: 0x7fb7fe1ef100, stack size: 4198144, maximum stack size: 8388608 2025.07.28 11:52:27.827164 [ 17207 ] {843f77fd-10c6-418e-aec8-086925dc7938} PushingToViews: Failed to push block to view test_5.v1 (4ae2feef-b6fa-47ac-b20c-744da14b2a0a), Stack size too large. Stack address: 0x7fb7fddf0000, frame address: 0x7fb7fe1ef100, stack size: 4198144, maximum stack size: 8388608 2025.07.28 11:52:27.829691 [ 17207 ] {843f77fd-10c6-418e-aec8-086925dc7938} PushingToViews: Failed to push block to view test_5.v2 (7c22a887-3ed3-40f1-a092-d92463e4b87b), Stack size too large. Stack address: 0x7fb7fddf0000, frame address: 0x7fb7fe1ef100, stack size: 4198144, maximum stack size: 8388608 2025.07.28 11:52:27.831417 [ 17207 ] {843f77fd-10c6-418e-aec8-086925dc7938} PushingToViews: Failed to push block to view test_5.v1 (4ae2feef-b6fa-47ac-b20c-744da14b2a0a), Stack size too large. Stack address: 0x7fb7fddf0000, frame address: 0x7fb7fe1ef100, stack size: 4198144, maximum stack size: 8388608 2025.07.28 11:52:27.832762 [ 17207 ] {843f77fd-10c6-418e-aec8-086925dc7938} PushingToViews: Failed to push block to view test_5.v2 (7c22a887-3ed3-40f1-a092-d92463e4b87b), Stack size too large. Stack address: 0x7fb7fddf0000, frame address: 0x7fb7fe1ef100, stack size: 4198144, maximum stack size: 8388608 2025.07.28 11:52:27.842268 [ 17207 ] {843f77fd-10c6-418e-aec8-086925dc7938} PushingToViews: Failed to push block to view test_5.v1 (4ae2feef-b6fa-47ac-b20c-744da14b2a0a), Stack size too large. Stack address: 0x7fb7fddf0000, frame address: 0x7fb7fe1ef100, stack size: 4198144, maximum stack size: 8388608 2025.07.28 11:52:27.860244 [ 17207 ] {843f77fd-10c6-418e-aec8-086925dc7938} PushingToViews: Failed to push block to view test_5.v2 (7c22a887-3ed3-40f1-a092-d92463e4b87b), Stack size too large. Stack address: 0x7fb7fddf0000, frame address: 0x7fb7fe1ef100, stack size: 4198144, maximum stack size: 8388608 2025.07.28 11:52:27.864486 [ 17207 ] {843f77fd-10c6-418e-aec8-086925dc7938} PushingToViews: Failed to push block to view test_5.v1 (4ae2feef-b6fa-47ac-b20c-744da14b2a0a), Stack size too large. Stack address: 0x7fb7fddf0000, frame address: 0x7fb7fe1ef100, stack size: 4198144, maximum stack size: 8388608 2025.07.28 11:52:27.866525 [ 17207 ] {843f77fd-10c6-418e-aec8-086925dc7938} PushingToViews: Failed to push block to view test_5.v2 (7c22a887-3ed3-40f1-a092-d92463e4b87b), Stack size too large. Stack address: 0x7fb7fddf0000, frame address: 0x7fb7fe1ef100, stack size: 4198144, maximum stack size: 8388608 2025.07.28 11:52:27.871806 [ 17207 ] {843f77fd-10c6-418e-aec8-086925dc7938} PushingToViews: Failed to push block to view test_5.v1 (4ae2feef-b6fa-47ac-b20c-744da14b2a0a), Stack size too large. Stack address: 0x7fb7fddf0000, frame address: 0x7fb7fe1ef100, stack size: 4198144, maximum stack size: 8388608 2025.07.28 11:52:27.873776 [ 17207 ] {843f77fd-10c6-418e-aec8-086925dc7938} PushingToViews: Failed to push block to view test_5.v2 (7c22a887-3ed3-40f1-a092-d92463e4b87b), Stack size too large. Stack address: 0x7fb7fddf0000, frame address: 0x7fb7fe1ef100, stack size: 4198144, maximum stack size: 8388608 2025.07.28 11:52:27.879384 [ 17207 ] {843f77fd-10c6-418e-aec8-086925dc7938} PushingToViews: Failed to push block to view test_5.v1 (4ae2feef-b6fa-47ac-b20c-744da14b2a0a), Stack size too large. Stack address: 0x7fb7fddf0000, frame address: 0x7fb7fe1ef100, stack size: 4198144, maximum stack size: 8388608 2025.07.28 11:52:27.887479 [ 17207 ] {843f77fd-10c6-418e-aec8-086925dc7938} PushingToViews: Failed to push block to view test_5.v2 (7c22a887-3ed3-40f1-a092-d92463e4b87b), Stack size too large. Stack address: 0x7fb7fddf0000, frame address: 0x7fb7fe1ef100, stack size: 4198144, maximum stack size: 8388608 2025.07.28 11:52:27.891934 [ 17207 ] {843f77fd-10c6-418e-aec8-086925dc7938} PushingToViews: Failed to push block to view test_5.v1 (4ae2feef-b6fa-47ac-b20c-744da14b2a0a), Stack size too large. Stack address: 0x7fb7fddf0000, frame address: 0x7fb7fe1ef100, stack size: 4198144, maximum stack size: 8388608 2025.07.28 11:52:27.894439 [ 17207 ] {843f77fd-10c6-418e-aec8-086925dc7938} PushingToViews: Failed to push block to view test_5.v2 (7c22a887-3ed3-40f1-a092-d92463e4b87b), Stack size too large. Stack address: 0x7fb7fddf0000, frame address: 0x7fb7fe1ef100, stack size: 4198144, maximum stack size: 8388608 2025.07.28 11:52:27.896685 [ 17207 ] {843f77fd-10c6-418e-aec8-086925dc7938} PushingToViews: Failed to push block to view test_5.v1 (4ae2feef-b6fa-47ac-b20c-744da14b2a0a), Stack size too large. Stack address: 0x7fb7fddf0000, frame address: 0x7fb7fe1ef100, stack size: 4198144, maximum stack size: 8388608 2025.07.28 11:52:27.909477 [ 17207 ] {843f77fd-10c6-418e-aec8-086925dc7938} PushingToViews: Failed to push block to view test_5.v2 (7c22a887-3ed3-40f1-a092-d92463e4b87b), Stack size too large. Stack address: 0x7fb7fddf0000, frame address: 0x7fb7fe1ef100, stack size: 4198144, maximum stack size: 8388608 2025.07.28 11:52:27.911522 [ 17207 ] {843f77fd-10c6-418e-aec8-086925dc7938} PushingToViews: Failed to push block to view test_5.v1 (4ae2feef-b6fa-47ac-b20c-744da14b2a0a), Stack size too large. Stack address: 0x7fb7fddf0000, frame address: 0x7fb7fe1ef100, stack size: 4198144, maximum stack size: 8388608 2025.07.28 11:52:27.911151 [ 3961 ] {} test_13.alter_table1 (b6d50f9f-3cd1-4fee-aa3e-84cf679f8083): Part /var/lib/clickhouse/store/b6d/b6d50f9f-3cd1-4fee-aa3e-84cf679f8083/detached/all_51_51_0/ is broken and needs manual correction. Reason: Code: 226. DB::Exception: No columns.txt in part all_91_91_0, expected path store/b6d/b6d50f9f-3cd1-4fee-aa3e-84cf679f8083/detached/all_51_51_0/columns.txt on drive default. (NO_FILE_IN_DATA_PART), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, String&, String&&) @ 0x0000000012da2e0b 4. /build/src/Storages/MergeTree/IMergeTreeDataPart.cpp:1629: DB::IMergeTreeDataPart::loadColumns(bool) @ 0x000000001625bb62 5. /build/src/Storages/MergeTree/IMergeTreeDataPart.cpp:839: DB::IMergeTreeDataPart::loadColumnsChecksumsIndexes(bool, bool) @ 0x0000000016259f5b 6. /build/src/Storages/StorageReplicatedMergeTree.cpp:2237: DB::StorageReplicatedMergeTree::attachPartHelperFoundValidPart(DB::ReplicatedMergeTreeLogEntry const&) const @ 0x0000000015eb838f 7. /build/src/Storages/StorageReplicatedMergeTree.cpp:2309: DB::StorageReplicatedMergeTree::executeLogEntry(DB::ReplicatedMergeTreeLogEntry&) @ 0x0000000015eb969e 8. /build/src/Storages/StorageReplicatedMergeTree.cpp:3876: bool std::__function::__policy_invoker&)>::__call_impl[abi:se190107])::$_1, bool (std::shared_ptr&)>>(std::__function::__policy_storage const*, std::shared_ptr&) @ 0x0000000015f9837e 9. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000165d6fc3 10. /build/src/Storages/StorageReplicatedMergeTree.cpp:3872: DB::StorageReplicatedMergeTree::processQueueEntry(std::shared_ptr) @ 0x0000000015efc18a 11. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001624c1b2 12. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000162f9c70 13. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x00000000162fa55a 14. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc6653 15. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000000fccc4c3 16. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc3d92 17. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fcca080 18. ? @ 0x00007fbc6213eac3 19. ? @ 0x00007fbc621d0850 (version 25.3.6.10636.altinitytest (altinity build)) 2025.07.28 11:52:27.913346 [ 17207 ] {843f77fd-10c6-418e-aec8-086925dc7938} PushingToViews: Failed to push block to view test_5.v2 (7c22a887-3ed3-40f1-a092-d92463e4b87b), Stack size too large. Stack address: 0x7fb7fddf0000, frame address: 0x7fb7fe1ef100, stack size: 4198144, maximum stack size: 8388608 2025.07.28 11:52:27.924292 [ 17207 ] {843f77fd-10c6-418e-aec8-086925dc7938} PushingToViews: Failed to push block to view test_5.v1 (4ae2feef-b6fa-47ac-b20c-744da14b2a0a), Stack size too large. Stack address: 0x7fb7fddf0000, frame address: 0x7fb7fe1ef100, stack size: 4198144, maximum stack size: 8388608 2025.07.28 11:52:27.928748 [ 17207 ] {843f77fd-10c6-418e-aec8-086925dc7938} PushingToViews: Failed to push block to view test_5.v2 (7c22a887-3ed3-40f1-a092-d92463e4b87b), Stack size too large. Stack address: 0x7fb7fddf0000, frame address: 0x7fb7fe1ef100, stack size: 4198144, maximum stack size: 8388608 2025.07.28 11:52:27.935552 [ 17207 ] {843f77fd-10c6-418e-aec8-086925dc7938} PushingToViews: Failed to push block to view test_5.v1 (4ae2feef-b6fa-47ac-b20c-744da14b2a0a), Stack size too large. Stack address: 0x7fb7fddf0000, frame address: 0x7fb7fe1ef100, stack size: 4198144, maximum stack size: 8388608 2025.07.28 11:52:28.006657 [ 17207 ] {843f77fd-10c6-418e-aec8-086925dc7938} PushingToViews: Failed to push block to view test_5.v2 (7c22a887-3ed3-40f1-a092-d92463e4b87b), Stack size too large. Stack address: 0x7fb7fddf0000, frame address: 0x7fb7fe1ef100, stack size: 4198144, maximum stack size: 8388608 2025.07.28 11:52:28.010027 [ 17207 ] {843f77fd-10c6-418e-aec8-086925dc7938} PushingToViews: Failed to push block to view test_5.v1 (4ae2feef-b6fa-47ac-b20c-744da14b2a0a), Stack size too large. Stack address: 0x7fb7fddf0000, frame address: 0x7fb7fe1ef100, stack size: 4198144, maximum stack size: 8388608 2025.07.28 11:52:28.013300 [ 17207 ] {843f77fd-10c6-418e-aec8-086925dc7938} PushingToViews: Failed to push block to view test_5.v2 (7c22a887-3ed3-40f1-a092-d92463e4b87b), Stack size too large. Stack address: 0x7fb7fddf0000, frame address: 0x7fb7fe1ef100, stack size: 4198144, maximum stack size: 8388608 2025.07.28 11:52:28.029164 [ 17207 ] {843f77fd-10c6-418e-aec8-086925dc7938} PushingToViews: Failed to push block to view test_5.v1 (4ae2feef-b6fa-47ac-b20c-744da14b2a0a), Stack size too large. Stack address: 0x7fb7fddf0000, frame address: 0x7fb7fe1ef100, stack size: 4198144, maximum stack size: 8388608 2025.07.28 11:52:28.032698 [ 17207 ] {843f77fd-10c6-418e-aec8-086925dc7938} PushingToViews: Failed to push block to view test_5.v2 (7c22a887-3ed3-40f1-a092-d92463e4b87b), Stack size too large. Stack address: 0x7fb7fddf0000, frame address: 0x7fb7fe1ef100, stack size: 4198144, maximum stack size: 8388608 2025.07.28 11:52:28.035633 [ 17207 ] {843f77fd-10c6-418e-aec8-086925dc7938} PushingToViews: Failed to push block to view test_5.v1 (4ae2feef-b6fa-47ac-b20c-744da14b2a0a), Stack size too large. Stack address: 0x7fb7fddf0000, frame address: 0x7fb7fe1ef100, stack size: 4198144, maximum stack size: 8388608 2025.07.28 11:52:28.039298 [ 17207 ] {843f77fd-10c6-418e-aec8-086925dc7938} PushingToViews: Failed to push block to view test_5.v2 (7c22a887-3ed3-40f1-a092-d92463e4b87b), Stack size too large. Stack address: 0x7fb7fddf0000, frame address: 0x7fb7fe1ef100, stack size: 4198144, maximum stack size: 8388608 2025.07.28 11:52:28.058795 [ 17207 ] {843f77fd-10c6-418e-aec8-086925dc7938} PushingToViews: Failed to push block to view test_5.v1 (4ae2feef-b6fa-47ac-b20c-744da14b2a0a), Stack size too large. Stack address: 0x7fb7fddf0000, frame address: 0x7fb7fe1ef100, stack size: 4198144, maximum stack size: 8388608 2025.07.28 11:52:28.060441 [ 17207 ] {843f77fd-10c6-418e-aec8-086925dc7938} PushingToViews: Failed to push block to view test_5.v2 (7c22a887-3ed3-40f1-a092-d92463e4b87b), Stack size too large. Stack address: 0x7fb7fddf0000, frame address: 0x7fb7fe1ef100, stack size: 4198144, maximum stack size: 8388608 2025.07.28 11:52:28.061949 [ 17207 ] {843f77fd-10c6-418e-aec8-086925dc7938} PushingToViews: Failed to push block to view test_5.v1 (4ae2feef-b6fa-47ac-b20c-744da14b2a0a), Stack size too large. Stack address: 0x7fb7fddf0000, frame address: 0x7fb7fe1ef100, stack size: 4198144, maximum stack size: 8388608 2025.07.28 11:52:28.067242 [ 17207 ] {843f77fd-10c6-418e-aec8-086925dc7938} PushingToViews: Failed to push block to view test_5.v2 (7c22a887-3ed3-40f1-a092-d92463e4b87b), Stack size too large. Stack address: 0x7fb7fddf0000, frame address: 0x7fb7fe1ef100, stack size: 4198144, maximum stack size: 8388608 2025.07.28 11:52:28.073628 [ 17207 ] {843f77fd-10c6-418e-aec8-086925dc7938} PushingToViews: Failed to push block to view test_5.v1 (4ae2feef-b6fa-47ac-b20c-744da14b2a0a), Stack size too large. Stack address: 0x7fb7fddf0000, frame address: 0x7fb7fe1ef100, stack size: 4198144, maximum stack size: 8388608 2025.07.28 11:52:28.079884 [ 17207 ] {843f77fd-10c6-418e-aec8-086925dc7938} PushingToViews: Failed to push block to view test_5.v2 (7c22a887-3ed3-40f1-a092-d92463e4b87b), Stack size too large. Stack address: 0x7fb7fddf0000, frame address: 0x7fb7fe1ef100, stack size: 4198144, maximum stack size: 8388608 2025.07.28 11:52:28.081553 [ 17207 ] {843f77fd-10c6-418e-aec8-086925dc7938} PushingToViews: Failed to push block to view test_5.v1 (4ae2feef-b6fa-47ac-b20c-744da14b2a0a), Stack size too large. Stack address: 0x7fb7fddf0000, frame address: 0x7fb7fe1ef100, stack size: 4198144, maximum stack size: 8388608 2025.07.28 11:52:28.084742 [ 17207 ] {843f77fd-10c6-418e-aec8-086925dc7938} PushingToViews: Failed to push block to view test_5.v2 (7c22a887-3ed3-40f1-a092-d92463e4b87b), Stack size too large. Stack address: 0x7fb7fddf0000, frame address: 0x7fb7fe1ef100, stack size: 4198144, maximum stack size: 8388608 2025.07.28 11:52:28.085813 [ 17207 ] {843f77fd-10c6-418e-aec8-086925dc7938} PushingToViews: Failed to push block to view test_5.v1 (4ae2feef-b6fa-47ac-b20c-744da14b2a0a), Stack size too large. Stack address: 0x7fb7fddf0000, frame address: 0x7fb7fe1ef100, stack size: 4198144, maximum stack size: 8388608 2025.07.28 11:52:28.087398 [ 17207 ] {843f77fd-10c6-418e-aec8-086925dc7938} PushingToViews: Failed to push block to view test_5.v2 (7c22a887-3ed3-40f1-a092-d92463e4b87b), Stack size too large. Stack address: 0x7fb7fddf0000, frame address: 0x7fb7fe1ef100, stack size: 4198144, maximum stack size: 8388608 2025.07.28 11:52:28.089581 [ 17207 ] {843f77fd-10c6-418e-aec8-086925dc7938} PushingToViews: Failed to push block to view test_5.v1 (4ae2feef-b6fa-47ac-b20c-744da14b2a0a), Stack size too large. Stack address: 0x7fb7fddf0000, frame address: 0x7fb7fe1ef100, stack size: 4198144, maximum stack size: 8388608 2025.07.28 11:52:28.090624 [ 17207 ] {843f77fd-10c6-418e-aec8-086925dc7938} PushingToViews: Failed to push block to view test_5.v2 (7c22a887-3ed3-40f1-a092-d92463e4b87b), Stack size too large. Stack address: 0x7fb7fddf0000, frame address: 0x7fb7fe1ef100, stack size: 4198144, maximum stack size: 8388608 2025.07.28 11:52:28.092306 [ 17207 ] {843f77fd-10c6-418e-aec8-086925dc7938} PushingToViews: Failed to push block to view test_5.v1 (4ae2feef-b6fa-47ac-b20c-744da14b2a0a), Stack size too large. Stack address: 0x7fb7fddf0000, frame address: 0x7fb7fe1ef100, stack size: 4198144, maximum stack size: 8388608 2025.07.28 11:52:28.093951 [ 17207 ] {843f77fd-10c6-418e-aec8-086925dc7938} PushingToViews: Failed to push block to view test_5.v2 (7c22a887-3ed3-40f1-a092-d92463e4b87b), Stack size too large. Stack address: 0x7fb7fddf0000, frame address: 0x7fb7fe1ef100, stack size: 4198144, maximum stack size: 8388608 2025.07.28 11:52:28.096437 [ 17207 ] {843f77fd-10c6-418e-aec8-086925dc7938} PushingToViews: Failed to push block to view test_5.v1 (4ae2feef-b6fa-47ac-b20c-744da14b2a0a), Stack size too large. Stack address: 0x7fb7fddf0000, frame address: 0x7fb7fe1ef100, stack size: 4198144, maximum stack size: 8388608 2025.07.28 11:52:28.098240 [ 17207 ] {843f77fd-10c6-418e-aec8-086925dc7938} PushingToViews: Failed to push block to view test_5.v2 (7c22a887-3ed3-40f1-a092-d92463e4b87b), Stack size too large. Stack address: 0x7fb7fddf0000, frame address: 0x7fb7fe1ef100, stack size: 4198144, maximum stack size: 8388608 2025.07.28 11:52:28.099876 [ 17207 ] {843f77fd-10c6-418e-aec8-086925dc7938} PushingToViews: Failed to push block to view test_5.v1 (4ae2feef-b6fa-47ac-b20c-744da14b2a0a), Stack size too large. Stack address: 0x7fb7fddf0000, frame address: 0x7fb7fe1ef100, stack size: 4198144, maximum stack size: 8388608 2025.07.28 11:52:28.101986 [ 17207 ] {843f77fd-10c6-418e-aec8-086925dc7938} PushingToViews: Failed to push block to view test_5.v2 (7c22a887-3ed3-40f1-a092-d92463e4b87b), Stack size too large. Stack address: 0x7fb7fddf0000, frame address: 0x7fb7fe1ef100, stack size: 4198144, maximum stack size: 8388608 2025.07.28 11:52:28.102805 [ 17207 ] {843f77fd-10c6-418e-aec8-086925dc7938} PushingToViews: Failed to push block to view test_5.v1 (4ae2feef-b6fa-47ac-b20c-744da14b2a0a), Stack size too large. Stack address: 0x7fb7fddf0000, frame address: 0x7fb7fe1ef100, stack size: 4198144, maximum stack size: 8388608 2025.07.28 11:52:28.104430 [ 17207 ] {843f77fd-10c6-418e-aec8-086925dc7938} PushingToViews: Failed to push block to view test_5.v2 (7c22a887-3ed3-40f1-a092-d92463e4b87b), Stack size too large. Stack address: 0x7fb7fddf0000, frame address: 0x7fb7fe1ef100, stack size: 4198144, maximum stack size: 8388608 2025.07.28 11:52:28.106235 [ 17207 ] {843f77fd-10c6-418e-aec8-086925dc7938} PushingToViews: Failed to push block to view test_5.v1 (4ae2feef-b6fa-47ac-b20c-744da14b2a0a), Stack size too large. Stack address: 0x7fb7fddf0000, frame address: 0x7fb7fe1ef100, stack size: 4198144, maximum stack size: 8388608 2025.07.28 11:52:28.107183 [ 17207 ] {843f77fd-10c6-418e-aec8-086925dc7938} PushingToViews: Failed to push block to view test_5.v2 (7c22a887-3ed3-40f1-a092-d92463e4b87b), Stack size too large. Stack address: 0x7fb7fddf0000, frame address: 0x7fb7fe1ef100, stack size: 4198144, maximum stack size: 8388608 2025.07.28 11:52:28.108066 [ 17207 ] {843f77fd-10c6-418e-aec8-086925dc7938} PushingToViews: Failed to push block to view test_5.v1 (4ae2feef-b6fa-47ac-b20c-744da14b2a0a), Stack size too large. Stack address: 0x7fb7fddf0000, frame address: 0x7fb7fe1ef100, stack size: 4198144, maximum stack size: 8388608 2025.07.28 11:52:28.109483 [ 17207 ] {843f77fd-10c6-418e-aec8-086925dc7938} PushingToViews: Failed to push block to view test_5.v2 (7c22a887-3ed3-40f1-a092-d92463e4b87b), Stack size too large. Stack address: 0x7fb7fddf0000, frame address: 0x7fb7fe1ef100, stack size: 4198144, maximum stack size: 8388608 2025.07.28 11:52:28.111147 [ 17207 ] {843f77fd-10c6-418e-aec8-086925dc7938} PushingToViews: Failed to push block to view test_5.v1 (4ae2feef-b6fa-47ac-b20c-744da14b2a0a), Stack size too large. Stack address: 0x7fb7fddf0000, frame address: 0x7fb7fe1ef100, stack size: 4198144, maximum stack size: 8388608 2025.07.28 11:52:28.114569 [ 17207 ] {843f77fd-10c6-418e-aec8-086925dc7938} PushingToViews: Failed to push block to view test_5.v2 (7c22a887-3ed3-40f1-a092-d92463e4b87b), Stack size too large. Stack address: 0x7fb7fddf0000, frame address: 0x7fb7fe1ef100, stack size: 4198144, maximum stack size: 8388608 2025.07.28 11:52:28.116596 [ 3974 ] {} test_13.alter_table1 (b6d50f9f-3cd1-4fee-aa3e-84cf679f8083): Part /var/lib/clickhouse/store/b6d/b6d50f9f-3cd1-4fee-aa3e-84cf679f8083/detached/all_74_74_0/ is broken and needs manual correction. Reason: Code: 226. DB::Exception: No columns.txt in part all_94_94_0, expected path store/b6d/b6d50f9f-3cd1-4fee-aa3e-84cf679f8083/detached/all_74_74_0/columns.txt on drive default. (NO_FILE_IN_DATA_PART), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, String&, String&&) @ 0x0000000012da2e0b 4. /build/src/Storages/MergeTree/IMergeTreeDataPart.cpp:1629: DB::IMergeTreeDataPart::loadColumns(bool) @ 0x000000001625bb62 5. /build/src/Storages/MergeTree/IMergeTreeDataPart.cpp:839: DB::IMergeTreeDataPart::loadColumnsChecksumsIndexes(bool, bool) @ 0x0000000016259f5b 6. /build/src/Storages/StorageReplicatedMergeTree.cpp:2237: DB::StorageReplicatedMergeTree::attachPartHelperFoundValidPart(DB::ReplicatedMergeTreeLogEntry const&) const @ 0x0000000015eb838f 7. /build/src/Storages/StorageReplicatedMergeTree.cpp:2309: DB::StorageReplicatedMergeTree::executeLogEntry(DB::ReplicatedMergeTreeLogEntry&) @ 0x0000000015eb969e 8. /build/src/Storages/StorageReplicatedMergeTree.cpp:3876: bool std::__function::__policy_invoker&)>::__call_impl[abi:se190107])::$_1, bool (std::shared_ptr&)>>(std::__function::__policy_storage const*, std::shared_ptr&) @ 0x0000000015f9837e 9. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000165d6fc3 10. /build/src/Storages/StorageReplicatedMergeTree.cpp:3872: DB::StorageReplicatedMergeTree::processQueueEntry(std::shared_ptr) @ 0x0000000015efc18a 11. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001624c1b2 12. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000162f9c70 13. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x00000000162fa55a 14. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc6653 15. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000000fccc4c3 16. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc3d92 17. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fcca080 18. ? @ 0x00007fbc6213eac3 19. ? @ 0x00007fbc621d0850 (version 25.3.6.10636.altinitytest (altinity build)) 2025.07.28 11:52:28.116692 [ 17207 ] {843f77fd-10c6-418e-aec8-086925dc7938} PushingToViews: Failed to push block to view test_5.v1 (4ae2feef-b6fa-47ac-b20c-744da14b2a0a), Stack size too large. Stack address: 0x7fb7fddf0000, frame address: 0x7fb7fe1ef100, stack size: 4198144, maximum stack size: 8388608 2025.07.28 11:52:28.118954 [ 17207 ] {843f77fd-10c6-418e-aec8-086925dc7938} PushingToViews: Failed to push block to view test_5.v2 (7c22a887-3ed3-40f1-a092-d92463e4b87b), Stack size too large. Stack address: 0x7fb7fddf0000, frame address: 0x7fb7fe1ef100, stack size: 4198144, maximum stack size: 8388608 2025.07.28 11:52:28.119910 [ 17207 ] {843f77fd-10c6-418e-aec8-086925dc7938} PushingToViews: Failed to push block to view test_5.v1 (4ae2feef-b6fa-47ac-b20c-744da14b2a0a), Stack size too large. Stack address: 0x7fb7fddf0000, frame address: 0x7fb7fe1ef100, stack size: 4198144, maximum stack size: 8388608 2025.07.28 11:52:28.121896 [ 17207 ] {843f77fd-10c6-418e-aec8-086925dc7938} PushingToViews: Failed to push block to view test_5.v2 (7c22a887-3ed3-40f1-a092-d92463e4b87b), Stack size too large. Stack address: 0x7fb7fddf0000, frame address: 0x7fb7fe1ef100, stack size: 4198144, maximum stack size: 8388608 2025.07.28 11:52:28.122773 [ 17207 ] {843f77fd-10c6-418e-aec8-086925dc7938} PushingToViews: Failed to push block to view test_5.v1 (4ae2feef-b6fa-47ac-b20c-744da14b2a0a), Stack size too large. Stack address: 0x7fb7fddf0000, frame address: 0x7fb7fe1ef100, stack size: 4198144, maximum stack size: 8388608 2025.07.28 11:52:28.123642 [ 17207 ] {843f77fd-10c6-418e-aec8-086925dc7938} PushingToViews: Failed to push block to view test_5.v2 (7c22a887-3ed3-40f1-a092-d92463e4b87b), Stack size too large. Stack address: 0x7fb7fddf0000, frame address: 0x7fb7fe1ef100, stack size: 4198144, maximum stack size: 8388608 2025.07.28 11:52:28.124513 [ 17207 ] {843f77fd-10c6-418e-aec8-086925dc7938} PushingToViews: Failed to push block to view test_5.v1 (4ae2feef-b6fa-47ac-b20c-744da14b2a0a), Stack size too large. Stack address: 0x7fb7fddf0000, frame address: 0x7fb7fe1ef100, stack size: 4198144, maximum stack size: 8388608 2025.07.28 11:52:28.129040 [ 17207 ] {843f77fd-10c6-418e-aec8-086925dc7938} PushingToViews: Failed to push block to view test_5.v2 (7c22a887-3ed3-40f1-a092-d92463e4b87b), Stack size too large. Stack address: 0x7fb7fddf0000, frame address: 0x7fb7fe1ef100, stack size: 4198144, maximum stack size: 8388608 2025.07.28 11:52:28.130892 [ 17207 ] {843f77fd-10c6-418e-aec8-086925dc7938} PushingToViews: Failed to push block to view test_5.v1 (4ae2feef-b6fa-47ac-b20c-744da14b2a0a), Stack size too large. Stack address: 0x7fb7fddf0000, frame address: 0x7fb7fe1ef100, stack size: 4198144, maximum stack size: 8388608 2025.07.28 11:52:28.132781 [ 17207 ] {843f77fd-10c6-418e-aec8-086925dc7938} PushingToViews: Failed to push block to view test_5.v2 (7c22a887-3ed3-40f1-a092-d92463e4b87b), Stack size too large. Stack address: 0x7fb7fddf0000, frame address: 0x7fb7fe1ef100, stack size: 4198144, maximum stack size: 8388608 2025.07.28 11:52:28.135224 [ 17207 ] {843f77fd-10c6-418e-aec8-086925dc7938} PushingToViews: Failed to push block to view test_5.v1 (4ae2feef-b6fa-47ac-b20c-744da14b2a0a), Stack size too large. Stack address: 0x7fb7fddf0000, frame address: 0x7fb7fe1ef100, stack size: 4198144, maximum stack size: 8388608 2025.07.28 11:52:28.136399 [ 17207 ] {843f77fd-10c6-418e-aec8-086925dc7938} PushingToViews: Failed to push block to view test_5.v2 (7c22a887-3ed3-40f1-a092-d92463e4b87b), Stack size too large. Stack address: 0x7fb7fddf0000, frame address: 0x7fb7fe1ef100, stack size: 4198144, maximum stack size: 8388608 2025.07.28 11:52:28.138322 [ 17207 ] {843f77fd-10c6-418e-aec8-086925dc7938} PushingToViews: Failed to push block to view test_5.v1 (4ae2feef-b6fa-47ac-b20c-744da14b2a0a), Stack size too large. Stack address: 0x7fb7fddf0000, frame address: 0x7fb7fe1ef100, stack size: 4198144, maximum stack size: 8388608 2025.07.28 11:52:28.141252 [ 17207 ] {843f77fd-10c6-418e-aec8-086925dc7938} PushingToViews: Failed to push block to view test_5.v2 (7c22a887-3ed3-40f1-a092-d92463e4b87b), Stack size too large. Stack address: 0x7fb7fddf0000, frame address: 0x7fb7fe1ef100, stack size: 4198144, maximum stack size: 8388608 2025.07.28 11:52:28.143373 [ 17207 ] {843f77fd-10c6-418e-aec8-086925dc7938} PushingToViews: Failed to push block to view test_5.v1 (4ae2feef-b6fa-47ac-b20c-744da14b2a0a), Stack size too large. Stack address: 0x7fb7fddf0000, frame address: 0x7fb7fe1ef100, stack size: 4198144, maximum stack size: 8388608 2025.07.28 11:52:28.156120 [ 17207 ] {843f77fd-10c6-418e-aec8-086925dc7938} PushingToViews: Failed to push block to view test_5.v2 (7c22a887-3ed3-40f1-a092-d92463e4b87b), Stack size too large. Stack address: 0x7fb7fddf0000, frame address: 0x7fb7fe1ef100, stack size: 4198144, maximum stack size: 8388608 2025.07.28 11:52:28.158128 [ 17207 ] {843f77fd-10c6-418e-aec8-086925dc7938} PushingToViews: Failed to push block to view test_5.v1 (4ae2feef-b6fa-47ac-b20c-744da14b2a0a), Stack size too large. Stack address: 0x7fb7fddf0000, frame address: 0x7fb7fe1ef100, stack size: 4198144, maximum stack size: 8388608 2025.07.28 11:52:28.161017 [ 17207 ] {843f77fd-10c6-418e-aec8-086925dc7938} PushingToViews: Failed to push block to view test_5.v2 (7c22a887-3ed3-40f1-a092-d92463e4b87b), Stack size too large. Stack address: 0x7fb7fddf0000, frame address: 0x7fb7fe1ef100, stack size: 4198144, maximum stack size: 8388608 2025.07.28 11:52:28.162251 [ 17207 ] {843f77fd-10c6-418e-aec8-086925dc7938} PushingToViews: Failed to push block to view test_5.v1 (4ae2feef-b6fa-47ac-b20c-744da14b2a0a), Stack size too large. Stack address: 0x7fb7fddf0000, frame address: 0x7fb7fe1ef100, stack size: 4198144, maximum stack size: 8388608 2025.07.28 11:52:28.164156 [ 17207 ] {843f77fd-10c6-418e-aec8-086925dc7938} PushingToViews: Failed to push block to view test_5.v2 (7c22a887-3ed3-40f1-a092-d92463e4b87b), Stack size too large. Stack address: 0x7fb7fddf0000, frame address: 0x7fb7fe1ef100, stack size: 4198144, maximum stack size: 8388608 2025.07.28 11:52:28.160923 [ 3974 ] {} test_13.alter_table1 (b6d50f9f-3cd1-4fee-aa3e-84cf679f8083): Part /var/lib/clickhouse/store/b6d/b6d50f9f-3cd1-4fee-aa3e-84cf679f8083/detached/all_72_72_0/ is broken and needs manual correction. Reason: Code: 226. DB::Exception: No columns.txt in part all_94_94_0, expected path store/b6d/b6d50f9f-3cd1-4fee-aa3e-84cf679f8083/detached/all_72_72_0/columns.txt on drive default. (NO_FILE_IN_DATA_PART), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, String&, String&&) @ 0x0000000012da2e0b 4. /build/src/Storages/MergeTree/IMergeTreeDataPart.cpp:1629: DB::IMergeTreeDataPart::loadColumns(bool) @ 0x000000001625bb62 5. /build/src/Storages/MergeTree/IMergeTreeDataPart.cpp:839: DB::IMergeTreeDataPart::loadColumnsChecksumsIndexes(bool, bool) @ 0x0000000016259f5b 6. /build/src/Storages/StorageReplicatedMergeTree.cpp:2237: DB::StorageReplicatedMergeTree::attachPartHelperFoundValidPart(DB::ReplicatedMergeTreeLogEntry const&) const @ 0x0000000015eb838f 7. /build/src/Storages/StorageReplicatedMergeTree.cpp:2309: DB::StorageReplicatedMergeTree::executeLogEntry(DB::ReplicatedMergeTreeLogEntry&) @ 0x0000000015eb969e 8. /build/src/Storages/StorageReplicatedMergeTree.cpp:3876: bool std::__function::__policy_invoker&)>::__call_impl[abi:se190107])::$_1, bool (std::shared_ptr&)>>(std::__function::__policy_storage const*, std::shared_ptr&) @ 0x0000000015f9837e 9. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000165d6fc3 10. /build/src/Storages/StorageReplicatedMergeTree.cpp:3872: DB::StorageReplicatedMergeTree::processQueueEntry(std::shared_ptr) @ 0x0000000015efc18a 11. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001624c1b2 12. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000162f9c70 13. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x00000000162fa55a 14. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc6653 15. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000000fccc4c3 16. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc3d92 17. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fcca080 18. ? @ 0x00007fbc6213eac3 19. ? @ 0x00007fbc621d0850 (version 25.3.6.10636.altinitytest (altinity build)) 2025.07.28 11:52:28.167252 [ 17207 ] {843f77fd-10c6-418e-aec8-086925dc7938} PushingToViews: Failed to push block to view test_5.v1 (4ae2feef-b6fa-47ac-b20c-744da14b2a0a), Stack size too large. Stack address: 0x7fb7fddf0000, frame address: 0x7fb7fe1ef100, stack size: 4198144, maximum stack size: 8388608 2025.07.28 11:52:28.185848 [ 17207 ] {843f77fd-10c6-418e-aec8-086925dc7938} PushingToViews: Failed to push block to view test_5.v2 (7c22a887-3ed3-40f1-a092-d92463e4b87b), Stack size too large. Stack address: 0x7fb7fddf0000, frame address: 0x7fb7fe1ef100, stack size: 4198144, maximum stack size: 8388608 2025.07.28 11:52:28.260124 [ 17207 ] {843f77fd-10c6-418e-aec8-086925dc7938} PushingToViews: Failed to push block to view test_5.v1 (4ae2feef-b6fa-47ac-b20c-744da14b2a0a), Stack size too large. Stack address: 0x7fb7fddf0000, frame address: 0x7fb7fe1ef100, stack size: 4198144, maximum stack size: 8388608 2025.07.28 11:52:28.261864 [ 17207 ] {843f77fd-10c6-418e-aec8-086925dc7938} PushingToViews: Failed to push block to view test_5.v2 (7c22a887-3ed3-40f1-a092-d92463e4b87b), Stack size too large. Stack address: 0x7fb7fddf0000, frame address: 0x7fb7fe1ef100, stack size: 4198144, maximum stack size: 8388608 2025.07.28 11:52:28.262664 [ 17207 ] {843f77fd-10c6-418e-aec8-086925dc7938} PushingToViews: Failed to push block to view test_5.v1 (4ae2feef-b6fa-47ac-b20c-744da14b2a0a), Stack size too large. Stack address: 0x7fb7fddf0000, frame address: 0x7fb7fe1ef100, stack size: 4198144, maximum stack size: 8388608 2025.07.28 11:52:28.263607 [ 17207 ] {843f77fd-10c6-418e-aec8-086925dc7938} PushingToViews: Failed to push block to view test_5.v2 (7c22a887-3ed3-40f1-a092-d92463e4b87b), Stack size too large. Stack address: 0x7fb7fddf0000, frame address: 0x7fb7fe1ef100, stack size: 4198144, maximum stack size: 8388608 2025.07.28 11:52:28.267492 [ 17207 ] {843f77fd-10c6-418e-aec8-086925dc7938} PushingToViews: Failed to push block to view test_5.v1 (4ae2feef-b6fa-47ac-b20c-744da14b2a0a), Stack size too large. Stack address: 0x7fb7fddf0000, frame address: 0x7fb7fe1ef100, stack size: 4198144, maximum stack size: 8388608 2025.07.28 11:52:28.268230 [ 3972 ] {} test_13.alter_table1 (b6d50f9f-3cd1-4fee-aa3e-84cf679f8083): Part /var/lib/clickhouse/store/b6d/b6d50f9f-3cd1-4fee-aa3e-84cf679f8083/detached/all_72_72_0/ is broken and needs manual correction. Reason: Code: 226. DB::Exception: No columns.txt in part all_96_96_0, expected path store/b6d/b6d50f9f-3cd1-4fee-aa3e-84cf679f8083/detached/all_72_72_0/columns.txt on drive default. (NO_FILE_IN_DATA_PART), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, String&, String&&) @ 0x0000000012da2e0b 4. /build/src/Storages/MergeTree/IMergeTreeDataPart.cpp:1629: DB::IMergeTreeDataPart::loadColumns(bool) @ 0x000000001625bb62 5. /build/src/Storages/MergeTree/IMergeTreeDataPart.cpp:839: DB::IMergeTreeDataPart::loadColumnsChecksumsIndexes(bool, bool) @ 0x0000000016259f5b 6. /build/src/Storages/StorageReplicatedMergeTree.cpp:2237: DB::StorageReplicatedMergeTree::attachPartHelperFoundValidPart(DB::ReplicatedMergeTreeLogEntry const&) const @ 0x0000000015eb838f 7. /build/src/Storages/StorageReplicatedMergeTree.cpp:2309: DB::StorageReplicatedMergeTree::executeLogEntry(DB::ReplicatedMergeTreeLogEntry&) @ 0x0000000015eb969e 8. /build/src/Storages/StorageReplicatedMergeTree.cpp:3876: bool std::__function::__policy_invoker&)>::__call_impl[abi:se190107])::$_1, bool (std::shared_ptr&)>>(std::__function::__policy_storage const*, std::shared_ptr&) @ 0x0000000015f9837e 9. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000165d6fc3 10. /build/src/Storages/StorageReplicatedMergeTree.cpp:3872: DB::StorageReplicatedMergeTree::processQueueEntry(std::shared_ptr) @ 0x0000000015efc18a 11. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001624c1b2 12. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000162f9c70 13. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x00000000162fa55a 14. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc6653 15. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000000fccc4c3 16. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc3d92 17. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fcca080 18. ? @ 0x00007fbc6213eac3 19. ? @ 0x00007fbc621d0850 (version 25.3.6.10636.altinitytest (altinity build)) 2025.07.28 11:52:28.268935 [ 17207 ] {843f77fd-10c6-418e-aec8-086925dc7938} PushingToViews: Failed to push block to view test_5.v2 (7c22a887-3ed3-40f1-a092-d92463e4b87b), Stack size too large. Stack address: 0x7fb7fddf0000, frame address: 0x7fb7fe1ef100, stack size: 4198144, maximum stack size: 8388608 2025.07.28 11:52:28.270151 [ 17207 ] {843f77fd-10c6-418e-aec8-086925dc7938} PushingToViews: Failed to push block to view test_5.v1 (4ae2feef-b6fa-47ac-b20c-744da14b2a0a), Stack size too large. Stack address: 0x7fb7fddf0000, frame address: 0x7fb7fe1ef100, stack size: 4198144, maximum stack size: 8388608 2025.07.28 11:52:28.271062 [ 17207 ] {843f77fd-10c6-418e-aec8-086925dc7938} PushingToViews: Failed to push block to view test_5.v2 (7c22a887-3ed3-40f1-a092-d92463e4b87b), Stack size too large. Stack address: 0x7fb7fddf0000, frame address: 0x7fb7fe1ef100, stack size: 4198144, maximum stack size: 8388608 2025.07.28 11:52:28.276774 [ 17207 ] {843f77fd-10c6-418e-aec8-086925dc7938} PushingToViews: Failed to push block to view test_5.v1 (4ae2feef-b6fa-47ac-b20c-744da14b2a0a), Stack size too large. Stack address: 0x7fb7fddf0000, frame address: 0x7fb7fe1ef100, stack size: 4198144, maximum stack size: 8388608 2025.07.28 11:52:28.277922 [ 17207 ] {843f77fd-10c6-418e-aec8-086925dc7938} PushingToViews: Failed to push block to view test_5.v2 (7c22a887-3ed3-40f1-a092-d92463e4b87b), Stack size too large. Stack address: 0x7fb7fddf0000, frame address: 0x7fb7fe1ef100, stack size: 4198144, maximum stack size: 8388608 2025.07.28 11:52:28.279427 [ 17207 ] {843f77fd-10c6-418e-aec8-086925dc7938} PushingToViews: Failed to push block to view test_5.v1 (4ae2feef-b6fa-47ac-b20c-744da14b2a0a), Stack size too large. Stack address: 0x7fb7fddf0000, frame address: 0x7fb7fe1ef100, stack size: 4198144, maximum stack size: 8388608 2025.07.28 11:52:28.281273 [ 17207 ] {843f77fd-10c6-418e-aec8-086925dc7938} PushingToViews: Failed to push block to view test_5.v2 (7c22a887-3ed3-40f1-a092-d92463e4b87b), Stack size too large. Stack address: 0x7fb7fddf0000, frame address: 0x7fb7fe1ef100, stack size: 4198144, maximum stack size: 8388608 2025.07.28 11:52:28.282704 [ 17207 ] {843f77fd-10c6-418e-aec8-086925dc7938} PushingToViews: Failed to push block to view test_5.v1 (4ae2feef-b6fa-47ac-b20c-744da14b2a0a), Stack size too large. Stack address: 0x7fb7fddf0000, frame address: 0x7fb7fe1ef100, stack size: 4198144, maximum stack size: 8388608 2025.07.28 11:52:28.284257 [ 17207 ] {843f77fd-10c6-418e-aec8-086925dc7938} PushingToViews: Failed to push block to view test_5.v2 (7c22a887-3ed3-40f1-a092-d92463e4b87b), Stack size too large. Stack address: 0x7fb7fddf0000, frame address: 0x7fb7fe1ef100, stack size: 4198144, maximum stack size: 8388608 2025.07.28 11:52:28.293581 [ 17207 ] {843f77fd-10c6-418e-aec8-086925dc7938} PushingToViews: Failed to push block to view test_5.v1 (4ae2feef-b6fa-47ac-b20c-744da14b2a0a), Stack size too large. Stack address: 0x7fb7fddf0000, frame address: 0x7fb7fe1ef100, stack size: 4198144, maximum stack size: 8388608 2025.07.28 11:52:28.296392 [ 17207 ] {843f77fd-10c6-418e-aec8-086925dc7938} PushingToViews: Failed to push block to view test_5.v2 (7c22a887-3ed3-40f1-a092-d92463e4b87b), Stack size too large. Stack address: 0x7fb7fddf0000, frame address: 0x7fb7fe1ef100, stack size: 4198144, maximum stack size: 8388608 2025.07.28 11:52:28.298049 [ 17207 ] {843f77fd-10c6-418e-aec8-086925dc7938} PushingToViews: Failed to push block to view test_5.v1 (4ae2feef-b6fa-47ac-b20c-744da14b2a0a), Stack size too large. Stack address: 0x7fb7fddf0000, frame address: 0x7fb7fe1ef100, stack size: 4198144, maximum stack size: 8388608 2025.07.28 11:52:28.299092 [ 17207 ] {843f77fd-10c6-418e-aec8-086925dc7938} PushingToViews: Failed to push block to view test_5.v2 (7c22a887-3ed3-40f1-a092-d92463e4b87b), Stack size too large. Stack address: 0x7fb7fddf0000, frame address: 0x7fb7fe1ef100, stack size: 4198144, maximum stack size: 8388608 2025.07.28 11:52:28.301924 [ 17207 ] {843f77fd-10c6-418e-aec8-086925dc7938} PushingToViews: Failed to push block to view test_5.v1 (4ae2feef-b6fa-47ac-b20c-744da14b2a0a), Stack size too large. Stack address: 0x7fb7fddf0000, frame address: 0x7fb7fe1ef100, stack size: 4198144, maximum stack size: 8388608 2025.07.28 11:52:28.303416 [ 17207 ] {843f77fd-10c6-418e-aec8-086925dc7938} PushingToViews: Failed to push block to view test_5.v2 (7c22a887-3ed3-40f1-a092-d92463e4b87b), Stack size too large. Stack address: 0x7fb7fddf0000, frame address: 0x7fb7fe1ef100, stack size: 4198144, maximum stack size: 8388608 2025.07.28 11:52:28.303808 [ 3972 ] {} test_13.alter_table1 (b6d50f9f-3cd1-4fee-aa3e-84cf679f8083): Part /var/lib/clickhouse/store/b6d/b6d50f9f-3cd1-4fee-aa3e-84cf679f8083/detached/all_54_54_0/ is broken and needs manual correction. Reason: Code: 226. DB::Exception: No columns.txt in part all_96_96_0, expected path store/b6d/b6d50f9f-3cd1-4fee-aa3e-84cf679f8083/detached/all_54_54_0/columns.txt on drive default. (NO_FILE_IN_DATA_PART), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, String&, String&&) @ 0x0000000012da2e0b 4. /build/src/Storages/MergeTree/IMergeTreeDataPart.cpp:1629: DB::IMergeTreeDataPart::loadColumns(bool) @ 0x000000001625bb62 5. /build/src/Storages/MergeTree/IMergeTreeDataPart.cpp:839: DB::IMergeTreeDataPart::loadColumnsChecksumsIndexes(bool, bool) @ 0x0000000016259f5b 6. /build/src/Storages/StorageReplicatedMergeTree.cpp:2237: DB::StorageReplicatedMergeTree::attachPartHelperFoundValidPart(DB::ReplicatedMergeTreeLogEntry const&) const @ 0x0000000015eb838f 7. /build/src/Storages/StorageReplicatedMergeTree.cpp:2309: DB::StorageReplicatedMergeTree::executeLogEntry(DB::ReplicatedMergeTreeLogEntry&) @ 0x0000000015eb969e 8. /build/src/Storages/StorageReplicatedMergeTree.cpp:3876: bool std::__function::__policy_invoker&)>::__call_impl[abi:se190107])::$_1, bool (std::shared_ptr&)>>(std::__function::__policy_storage const*, std::shared_ptr&) @ 0x0000000015f9837e 9. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000165d6fc3 10. /build/src/Storages/StorageReplicatedMergeTree.cpp:3872: DB::StorageReplicatedMergeTree::processQueueEntry(std::shared_ptr) @ 0x0000000015efc18a 11. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001624c1b2 12. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000162f9c70 13. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x00000000162fa55a 14. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc6653 15. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000000fccc4c3 16. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc3d92 17. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fcca080 18. ? @ 0x00007fbc6213eac3 19. ? @ 0x00007fbc621d0850 (version 25.3.6.10636.altinitytest (altinity build)) 2025.07.28 11:52:28.305186 [ 17207 ] {843f77fd-10c6-418e-aec8-086925dc7938} PushingToViews: Failed to push block to view test_5.v1 (4ae2feef-b6fa-47ac-b20c-744da14b2a0a), Stack size too large. Stack address: 0x7fb7fddf0000, frame address: 0x7fb7fe1ef100, stack size: 4198144, maximum stack size: 8388608 2025.07.28 11:52:28.307320 [ 17207 ] {843f77fd-10c6-418e-aec8-086925dc7938} PushingToViews: Failed to push block to view test_5.v2 (7c22a887-3ed3-40f1-a092-d92463e4b87b), Stack size too large. Stack address: 0x7fb7fddf0000, frame address: 0x7fb7fe1ef100, stack size: 4198144, maximum stack size: 8388608 2025.07.28 11:52:28.308545 [ 17207 ] {843f77fd-10c6-418e-aec8-086925dc7938} PushingToViews: Failed to push block to view test_5.v1 (4ae2feef-b6fa-47ac-b20c-744da14b2a0a), Stack size too large. Stack address: 0x7fb7fddf0000, frame address: 0x7fb7fe1ef100, stack size: 4198144, maximum stack size: 8388608 2025.07.28 11:52:28.309475 [ 17207 ] {843f77fd-10c6-418e-aec8-086925dc7938} PushingToViews: Failed to push block to view test_5.v2 (7c22a887-3ed3-40f1-a092-d92463e4b87b), Stack size too large. Stack address: 0x7fb7fddf0000, frame address: 0x7fb7fe1ef100, stack size: 4198144, maximum stack size: 8388608 2025.07.28 11:52:28.310417 [ 17207 ] {843f77fd-10c6-418e-aec8-086925dc7938} PushingToViews: Failed to push block to view test_5.v1 (4ae2feef-b6fa-47ac-b20c-744da14b2a0a), Stack size too large. Stack address: 0x7fb7fddf0000, frame address: 0x7fb7fe1ef100, stack size: 4198144, maximum stack size: 8388608 2025.07.28 11:52:28.312725 [ 17207 ] {843f77fd-10c6-418e-aec8-086925dc7938} PushingToViews: Failed to push block to view test_5.v2 (7c22a887-3ed3-40f1-a092-d92463e4b87b), Stack size too large. Stack address: 0x7fb7fddf0000, frame address: 0x7fb7fe1ef100, stack size: 4198144, maximum stack size: 8388608 2025.07.28 11:52:28.315034 [ 17207 ] {843f77fd-10c6-418e-aec8-086925dc7938} PushingToViews: Failed to push block to view test_5.v1 (4ae2feef-b6fa-47ac-b20c-744da14b2a0a), Stack size too large. Stack address: 0x7fb7fddf0000, frame address: 0x7fb7fe1ef100, stack size: 4198144, maximum stack size: 8388608 2025.07.28 11:52:28.316394 [ 17207 ] {843f77fd-10c6-418e-aec8-086925dc7938} PushingToViews: Failed to push block to view test_5.v2 (7c22a887-3ed3-40f1-a092-d92463e4b87b), Stack size too large. Stack address: 0x7fb7fddf0000, frame address: 0x7fb7fe1ef100, stack size: 4198144, maximum stack size: 8388608 2025.07.28 11:52:28.317886 [ 17207 ] {843f77fd-10c6-418e-aec8-086925dc7938} PushingToViews: Failed to push block to view test_5.v1 (4ae2feef-b6fa-47ac-b20c-744da14b2a0a), Stack size too large. Stack address: 0x7fb7fddf0000, frame address: 0x7fb7fe1ef100, stack size: 4198144, maximum stack size: 8388608 2025.07.28 11:52:28.319659 [ 17207 ] {843f77fd-10c6-418e-aec8-086925dc7938} PushingToViews: Failed to push block to view test_5.v2 (7c22a887-3ed3-40f1-a092-d92463e4b87b), Stack size too large. Stack address: 0x7fb7fddf0000, frame address: 0x7fb7fe1ef100, stack size: 4198144, maximum stack size: 8388608 2025.07.28 11:52:28.320614 [ 17207 ] {843f77fd-10c6-418e-aec8-086925dc7938} PushingToViews: Failed to push block to view test_5.v1 (4ae2feef-b6fa-47ac-b20c-744da14b2a0a), Stack size too large. Stack address: 0x7fb7fddf0000, frame address: 0x7fb7fe1ef100, stack size: 4198144, maximum stack size: 8388608 2025.07.28 11:52:28.322928 [ 17207 ] {843f77fd-10c6-418e-aec8-086925dc7938} PushingToViews: Failed to push block to view test_5.v2 (7c22a887-3ed3-40f1-a092-d92463e4b87b), Stack size too large. Stack address: 0x7fb7fddf0000, frame address: 0x7fb7fe1ef100, stack size: 4198144, maximum stack size: 8388608 2025.07.28 11:52:28.324185 [ 17207 ] {843f77fd-10c6-418e-aec8-086925dc7938} PushingToViews: Failed to push block to view test_5.v1 (4ae2feef-b6fa-47ac-b20c-744da14b2a0a), Stack size too large. Stack address: 0x7fb7fddf0000, frame address: 0x7fb7fe1ef100, stack size: 4198144, maximum stack size: 8388608 2025.07.28 11:52:28.325697 [ 17207 ] {843f77fd-10c6-418e-aec8-086925dc7938} PushingToViews: Failed to push block to view test_5.v2 (7c22a887-3ed3-40f1-a092-d92463e4b87b), Stack size too large. Stack address: 0x7fb7fddf0000, frame address: 0x7fb7fe1ef100, stack size: 4198144, maximum stack size: 8388608 2025.07.28 11:52:28.327435 [ 17207 ] {843f77fd-10c6-418e-aec8-086925dc7938} PushingToViews: Failed to push block to view test_5.v1 (4ae2feef-b6fa-47ac-b20c-744da14b2a0a), Stack size too large. Stack address: 0x7fb7fddf0000, frame address: 0x7fb7fe1ef100, stack size: 4198144, maximum stack size: 8388608 2025.07.28 11:52:28.328857 [ 17207 ] {843f77fd-10c6-418e-aec8-086925dc7938} PushingToViews: Failed to push block to view test_5.v2 (7c22a887-3ed3-40f1-a092-d92463e4b87b), Stack size too large. Stack address: 0x7fb7fddf0000, frame address: 0x7fb7fe1ef100, stack size: 4198144, maximum stack size: 8388608 2025.07.28 11:52:28.330380 [ 17207 ] {843f77fd-10c6-418e-aec8-086925dc7938} PushingToViews: Failed to push block to view test_5.v1 (4ae2feef-b6fa-47ac-b20c-744da14b2a0a), Stack size too large. Stack address: 0x7fb7fddf0000, frame address: 0x7fb7fe1ef100, stack size: 4198144, maximum stack size: 8388608 2025.07.28 11:52:28.332212 [ 17207 ] {843f77fd-10c6-418e-aec8-086925dc7938} PushingToViews: Failed to push block to view test_5.v2 (7c22a887-3ed3-40f1-a092-d92463e4b87b), Stack size too large. Stack address: 0x7fb7fddf0000, frame address: 0x7fb7fe1ef100, stack size: 4198144, maximum stack size: 8388608 2025.07.28 11:52:28.333514 [ 17207 ] {843f77fd-10c6-418e-aec8-086925dc7938} PushingToViews: Failed to push block to view test_5.v1 (4ae2feef-b6fa-47ac-b20c-744da14b2a0a), Stack size too large. Stack address: 0x7fb7fddf0000, frame address: 0x7fb7fe1ef100, stack size: 4198144, maximum stack size: 8388608 2025.07.28 11:52:28.335104 [ 17207 ] {843f77fd-10c6-418e-aec8-086925dc7938} PushingToViews: Failed to push block to view test_5.v2 (7c22a887-3ed3-40f1-a092-d92463e4b87b), Stack size too large. Stack address: 0x7fb7fddf0000, frame address: 0x7fb7fe1ef100, stack size: 4198144, maximum stack size: 8388608 2025.07.28 11:52:28.336472 [ 17207 ] {843f77fd-10c6-418e-aec8-086925dc7938} PushingToViews: Failed to push block to view test_5.v1 (4ae2feef-b6fa-47ac-b20c-744da14b2a0a), Stack size too large. Stack address: 0x7fb7fddf0000, frame address: 0x7fb7fe1ef100, stack size: 4198144, maximum stack size: 8388608 2025.07.28 11:52:28.338727 [ 17207 ] {843f77fd-10c6-418e-aec8-086925dc7938} PushingToViews: Failed to push block to view test_5.v2 (7c22a887-3ed3-40f1-a092-d92463e4b87b), Stack size too large. Stack address: 0x7fb7fddf0000, frame address: 0x7fb7fe1ef100, stack size: 4198144, maximum stack size: 8388608 2025.07.28 11:52:28.340013 [ 17207 ] {843f77fd-10c6-418e-aec8-086925dc7938} PushingToViews: Failed to push block to view test_5.v1 (4ae2feef-b6fa-47ac-b20c-744da14b2a0a), Stack size too large. Stack address: 0x7fb7fddf0000, frame address: 0x7fb7fe1ef100, stack size: 4198144, maximum stack size: 8388608 2025.07.28 11:52:28.341013 [ 17207 ] {843f77fd-10c6-418e-aec8-086925dc7938} PushingToViews: Failed to push block to view test_5.v2 (7c22a887-3ed3-40f1-a092-d92463e4b87b), Stack size too large. Stack address: 0x7fb7fddf0000, frame address: 0x7fb7fe1ef100, stack size: 4198144, maximum stack size: 8388608 2025.07.28 11:52:28.342546 [ 17207 ] {843f77fd-10c6-418e-aec8-086925dc7938} PushingToViews: Failed to push block to view test_5.v1 (4ae2feef-b6fa-47ac-b20c-744da14b2a0a), Stack size too large. Stack address: 0x7fb7fddf0000, frame address: 0x7fb7fe1ef100, stack size: 4198144, maximum stack size: 8388608 2025.07.28 11:52:28.348230 [ 17207 ] {843f77fd-10c6-418e-aec8-086925dc7938} PushingToViews: Failed to push block to view test_5.v2 (7c22a887-3ed3-40f1-a092-d92463e4b87b), Stack size too large. Stack address: 0x7fb7fddf0000, frame address: 0x7fb7fe1ef100, stack size: 4198144, maximum stack size: 8388608 2025.07.28 11:52:28.348983 [ 17207 ] {843f77fd-10c6-418e-aec8-086925dc7938} PushingToViews: Failed to push block to view test_5.v1 (4ae2feef-b6fa-47ac-b20c-744da14b2a0a), Stack size too large. Stack address: 0x7fb7fddf0000, frame address: 0x7fb7fe1ef100, stack size: 4198144, maximum stack size: 8388608 2025.07.28 11:52:28.350393 [ 17207 ] {843f77fd-10c6-418e-aec8-086925dc7938} PushingToViews: Failed to push block to view test_5.v2 (7c22a887-3ed3-40f1-a092-d92463e4b87b), Stack size too large. Stack address: 0x7fb7fddf0000, frame address: 0x7fb7fe1ef100, stack size: 4198144, maximum stack size: 8388608 2025.07.28 11:52:28.352444 [ 17207 ] {843f77fd-10c6-418e-aec8-086925dc7938} PushingToViews: Failed to push block to view test_5.v1 (4ae2feef-b6fa-47ac-b20c-744da14b2a0a), Stack size too large. Stack address: 0x7fb7fddf0000, frame address: 0x7fb7fe1ef100, stack size: 4198144, maximum stack size: 8388608 2025.07.28 11:52:28.353360 [ 17207 ] {843f77fd-10c6-418e-aec8-086925dc7938} PushingToViews: Failed to push block to view test_5.v2 (7c22a887-3ed3-40f1-a092-d92463e4b87b), Stack size too large. Stack address: 0x7fb7fddf0000, frame address: 0x7fb7fe1ef100, stack size: 4198144, maximum stack size: 8388608 2025.07.28 11:52:28.354380 [ 17207 ] {843f77fd-10c6-418e-aec8-086925dc7938} PushingToViews: Failed to push block to view test_5.v1 (4ae2feef-b6fa-47ac-b20c-744da14b2a0a), Stack size too large. Stack address: 0x7fb7fddf0000, frame address: 0x7fb7fe1ef100, stack size: 4198144, maximum stack size: 8388608 2025.07.28 11:52:28.360810 [ 17207 ] {843f77fd-10c6-418e-aec8-086925dc7938} PushingToViews: Failed to push block to view test_5.v2 (7c22a887-3ed3-40f1-a092-d92463e4b87b), Stack size too large. Stack address: 0x7fb7fddf0000, frame address: 0x7fb7fe1ef100, stack size: 4198144, maximum stack size: 8388608 2025.07.28 11:52:28.361787 [ 17207 ] {843f77fd-10c6-418e-aec8-086925dc7938} PushingToViews: Failed to push block to view test_5.v1 (4ae2feef-b6fa-47ac-b20c-744da14b2a0a), Stack size too large. Stack address: 0x7fb7fddf0000, frame address: 0x7fb7fe1ef100, stack size: 4198144, maximum stack size: 8388608 2025.07.28 11:52:28.362654 [ 17207 ] {843f77fd-10c6-418e-aec8-086925dc7938} PushingToViews: Failed to push block to view test_5.v2 (7c22a887-3ed3-40f1-a092-d92463e4b87b), Stack size too large. Stack address: 0x7fb7fddf0000, frame address: 0x7fb7fe1ef100, stack size: 4198144, maximum stack size: 8388608 2025.07.28 11:52:28.364519 [ 17207 ] {843f77fd-10c6-418e-aec8-086925dc7938} PushingToViews: Failed to push block to view test_5.v1 (4ae2feef-b6fa-47ac-b20c-744da14b2a0a), Stack size too large. Stack address: 0x7fb7fddf0000, frame address: 0x7fb7fe1ef100, stack size: 4198144, maximum stack size: 8388608 2025.07.28 11:52:28.365400 [ 17207 ] {843f77fd-10c6-418e-aec8-086925dc7938} PushingToViews: Failed to push block to view test_5.v2 (7c22a887-3ed3-40f1-a092-d92463e4b87b), Stack size too large. Stack address: 0x7fb7fddf0000, frame address: 0x7fb7fe1ef100, stack size: 4198144, maximum stack size: 8388608 2025.07.28 11:52:28.366267 [ 17207 ] {843f77fd-10c6-418e-aec8-086925dc7938} PushingToViews: Failed to push block to view test_5.v1 (4ae2feef-b6fa-47ac-b20c-744da14b2a0a), Stack size too large. Stack address: 0x7fb7fddf0000, frame address: 0x7fb7fe1ef100, stack size: 4198144, maximum stack size: 8388608 2025.07.28 11:52:28.367792 [ 17207 ] {843f77fd-10c6-418e-aec8-086925dc7938} PushingToViews: Failed to push block to view test_5.v2 (7c22a887-3ed3-40f1-a092-d92463e4b87b), Stack size too large. Stack address: 0x7fb7fddf0000, frame address: 0x7fb7fe1ef100, stack size: 4198144, maximum stack size: 8388608 2025.07.28 11:52:28.368889 [ 17207 ] {843f77fd-10c6-418e-aec8-086925dc7938} PushingToViews: Failed to push block to view test_5.v1 (4ae2feef-b6fa-47ac-b20c-744da14b2a0a), Stack size too large. Stack address: 0x7fb7fddf0000, frame address: 0x7fb7fe1ef100, stack size: 4198144, maximum stack size: 8388608 2025.07.28 11:52:28.369807 [ 17207 ] {843f77fd-10c6-418e-aec8-086925dc7938} PushingToViews: Failed to push block to view test_5.v2 (7c22a887-3ed3-40f1-a092-d92463e4b87b), Stack size too large. Stack address: 0x7fb7fddf0000, frame address: 0x7fb7fe1ef100, stack size: 4198144, maximum stack size: 8388608 2025.07.28 11:52:28.377982 [ 17207 ] {843f77fd-10c6-418e-aec8-086925dc7938} PushingToViews: Failed to push block to view test_5.v1 (4ae2feef-b6fa-47ac-b20c-744da14b2a0a), Stack size too large. Stack address: 0x7fb7fddf0000, frame address: 0x7fb7fe1ef100, stack size: 4198144, maximum stack size: 8388608 2025.07.28 11:52:28.379843 [ 17207 ] {843f77fd-10c6-418e-aec8-086925dc7938} PushingToViews: Failed to push block to view test_5.v2 (7c22a887-3ed3-40f1-a092-d92463e4b87b), Stack size too large. Stack address: 0x7fb7fddf0000, frame address: 0x7fb7fe1ef100, stack size: 4198144, maximum stack size: 8388608 2025.07.28 11:52:28.380643 [ 17207 ] {843f77fd-10c6-418e-aec8-086925dc7938} PushingToViews: Failed to push block to view test_5.v1 (4ae2feef-b6fa-47ac-b20c-744da14b2a0a), Stack size too large. Stack address: 0x7fb7fddf0000, frame address: 0x7fb7fe1ef100, stack size: 4198144, maximum stack size: 8388608 2025.07.28 11:52:28.381851 [ 17207 ] {843f77fd-10c6-418e-aec8-086925dc7938} PushingToViews: Failed to push block to view test_5.v2 (7c22a887-3ed3-40f1-a092-d92463e4b87b), Stack size too large. Stack address: 0x7fb7fddf0000, frame address: 0x7fb7fe1ef100, stack size: 4198144, maximum stack size: 8388608 2025.07.28 11:52:28.387895 [ 17207 ] {843f77fd-10c6-418e-aec8-086925dc7938} PushingToViews: Failed to push block to view test_5.v1 (4ae2feef-b6fa-47ac-b20c-744da14b2a0a), Stack size too large. Stack address: 0x7fb7fddf0000, frame address: 0x7fb7fe1ef100, stack size: 4198144, maximum stack size: 8388608 2025.07.28 11:52:28.389039 [ 17207 ] {843f77fd-10c6-418e-aec8-086925dc7938} PushingToViews: Failed to push block to view test_5.v2 (7c22a887-3ed3-40f1-a092-d92463e4b87b), Stack size too large. Stack address: 0x7fb7fddf0000, frame address: 0x7fb7fe1ef100, stack size: 4198144, maximum stack size: 8388608 2025.07.28 11:52:28.390695 [ 17207 ] {843f77fd-10c6-418e-aec8-086925dc7938} PushingToViews: Failed to push block to view test_5.v1 (4ae2feef-b6fa-47ac-b20c-744da14b2a0a), Stack size too large. Stack address: 0x7fb7fddf0000, frame address: 0x7fb7fe1ef100, stack size: 4198144, maximum stack size: 8388608 2025.07.28 11:52:28.396378 [ 11851 ] {6db74b0a-cb99-4e50-b788-5b2420a3a004} executeQuery: Code: 47. DB::Exception: Unknown expression or function identifier `x` in scope x = 1. Maybe you meant: ['a']. (UNKNOWN_IDENTIFIER) (version 25.3.6.10636.altinitytest (altinity build)) (from [::1]:57418) (comment: 02888_attach_partition_from_different_tables.sql) (query 13, line 89) (in query: SELECT * FROM attach_partition_t6 WHERE b = '1';), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.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&&) @ 0x000000001404b3b9 4. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3771: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000001401b849 5. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3980: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000014018e31 6. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:2925: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000001402fcbd 7. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3838: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000014019a9e 8. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:209: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000001401270e 9. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000014011fce 10. /build/src/Planner/Utils.cpp:458: DB::buildFilterInfo(std::shared_ptr, std::shared_ptr const&, std::shared_ptr&, std::unordered_set, std::equal_to, std::allocator>) @ 0x0000000013fe8bcf 11. /build/src/Planner/PlannerJoinTree.cpp:535: DB::(anonymous namespace)::buildQueryPlanForTableExpression(std::shared_ptr, std::shared_ptr const&, DB::SelectQueryInfo const&, DB::SelectQueryOptions const&, std::shared_ptr&, bool, bool) @ 0x00000000149956d3 12. /build/src/Planner/PlannerJoinTree.cpp:2252: DB::buildJoinTreeQueryPlan(std::shared_ptr const&, DB::SelectQueryInfo const&, DB::SelectQueryOptions&, std::unordered_set, std::equal_to, std::allocator> const&, std::shared_ptr&) @ 0x000000001498e109 13. /build/src/Planner/Planner.cpp:1553: DB::Planner::buildPlanForQueryNode() @ 0x0000000014979dae 14. /build/src/Planner/Planner.cpp:1308: DB::Planner::buildQueryPlanIfNeeded() @ 0x000000001497685c 15. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:255: DB::InterpreterSelectQueryAnalyzer::getQueryPlan() @ 0x000000001497476d 16. /build/src/Interpreters/executeQuery.cpp:1405: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88806 17. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 18. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 19. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 20. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 21. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 22. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 23. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 24. ? @ 0x00007fbc6213eac3 25. ? @ 0x00007fbc621d0850 2025.07.28 11:52:28.407400 [ 11851 ] {} TCPHandler: Code: 47. DB::Exception: Unknown expression or function identifier `x` in scope x = 1. Maybe you meant: ['a']. (UNKNOWN_IDENTIFIER), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.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&&) @ 0x000000001404b3b9 4. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3771: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000001401b849 5. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3980: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000014018e31 6. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:2925: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000001402fcbd 7. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3838: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000014019a9e 8. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:209: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000001401270e 9. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000014011fce 10. /build/src/Planner/Utils.cpp:458: DB::buildFilterInfo(std::shared_ptr, std::shared_ptr const&, std::shared_ptr&, std::unordered_set, std::equal_to, std::allocator>) @ 0x0000000013fe8bcf 11. /build/src/Planner/PlannerJoinTree.cpp:535: DB::(anonymous namespace)::buildQueryPlanForTableExpression(std::shared_ptr, std::shared_ptr const&, DB::SelectQueryInfo const&, DB::SelectQueryOptions const&, std::shared_ptr&, bool, bool) @ 0x00000000149956d3 12. /build/src/Planner/PlannerJoinTree.cpp:2252: DB::buildJoinTreeQueryPlan(std::shared_ptr const&, DB::SelectQueryInfo const&, DB::SelectQueryOptions&, std::unordered_set, std::equal_to, std::allocator> const&, std::shared_ptr&) @ 0x000000001498e109 13. /build/src/Planner/Planner.cpp:1553: DB::Planner::buildPlanForQueryNode() @ 0x0000000014979dae 14. /build/src/Planner/Planner.cpp:1308: DB::Planner::buildQueryPlanIfNeeded() @ 0x000000001497685c 15. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:255: DB::InterpreterSelectQueryAnalyzer::getQueryPlan() @ 0x000000001497476d 16. /build/src/Interpreters/executeQuery.cpp:1405: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88806 17. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 18. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 19. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 20. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 21. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 22. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 23. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 24. ? @ 0x00007fbc6213eac3 25. ? @ 0x00007fbc621d0850 2025.07.28 11:52:28.392295 [ 17207 ] {843f77fd-10c6-418e-aec8-086925dc7938} PushingToViews: Failed to push block to view test_5.v2 (7c22a887-3ed3-40f1-a092-d92463e4b87b), Stack size too large. Stack address: 0x7fb7fddf0000, frame address: 0x7fb7fe1ef100, stack size: 4198144, maximum stack size: 8388608 2025.07.28 11:52:28.411028 [ 17207 ] {843f77fd-10c6-418e-aec8-086925dc7938} PushingToViews: Failed to push block to view test_5.v1 (4ae2feef-b6fa-47ac-b20c-744da14b2a0a), Stack size too large. Stack address: 0x7fb7fddf0000, frame address: 0x7fb7fe1ef100, stack size: 4198144, maximum stack size: 8388608 2025.07.28 11:52:28.413209 [ 17207 ] {843f77fd-10c6-418e-aec8-086925dc7938} PushingToViews: Failed to push block to view test_5.v2 (7c22a887-3ed3-40f1-a092-d92463e4b87b), Stack size too large. Stack address: 0x7fb7fddf0000, frame address: 0x7fb7fe1ef100, stack size: 4198144, maximum stack size: 8388608 2025.07.28 11:52:28.415282 [ 17207 ] {843f77fd-10c6-418e-aec8-086925dc7938} PushingToViews: Failed to push block to view test_5.v1 (4ae2feef-b6fa-47ac-b20c-744da14b2a0a), Stack size too large. Stack address: 0x7fb7fddf0000, frame address: 0x7fb7fe1ef100, stack size: 4198144, maximum stack size: 8388608 2025.07.28 11:52:28.419415 [ 17207 ] {843f77fd-10c6-418e-aec8-086925dc7938} PushingToViews: Failed to push block to view test_5.v2 (7c22a887-3ed3-40f1-a092-d92463e4b87b), Stack size too large. Stack address: 0x7fb7fddf0000, frame address: 0x7fb7fe1ef100, stack size: 4198144, maximum stack size: 8388608 2025.07.28 11:52:28.421188 [ 17207 ] {843f77fd-10c6-418e-aec8-086925dc7938} PushingToViews: Failed to push block to view test_5.v1 (4ae2feef-b6fa-47ac-b20c-744da14b2a0a), Stack size too large. Stack address: 0x7fb7fddf0000, frame address: 0x7fb7fe1ef100, stack size: 4198144, maximum stack size: 8388608 2025.07.28 11:52:28.422189 [ 17207 ] {843f77fd-10c6-418e-aec8-086925dc7938} PushingToViews: Failed to push block to view test_5.v2 (7c22a887-3ed3-40f1-a092-d92463e4b87b), Stack size too large. Stack address: 0x7fb7fddf0000, frame address: 0x7fb7fe1ef100, stack size: 4198144, maximum stack size: 8388608 2025.07.28 11:52:28.426801 [ 17207 ] {843f77fd-10c6-418e-aec8-086925dc7938} PushingToViews: Failed to push block to view test_5.v1 (4ae2feef-b6fa-47ac-b20c-744da14b2a0a), Stack size too large. Stack address: 0x7fb7fddf0000, frame address: 0x7fb7fe1ef100, stack size: 4198144, maximum stack size: 8388608 2025.07.28 11:52:28.428849 [ 17207 ] {843f77fd-10c6-418e-aec8-086925dc7938} PushingToViews: Failed to push block to view test_5.v2 (7c22a887-3ed3-40f1-a092-d92463e4b87b), Stack size too large. Stack address: 0x7fb7fddf0000, frame address: 0x7fb7fe1ef100, stack size: 4198144, maximum stack size: 8388608 2025.07.28 11:52:28.434452 [ 17207 ] {843f77fd-10c6-418e-aec8-086925dc7938} PushingToViews: Failed to push block to view test_5.v1 (4ae2feef-b6fa-47ac-b20c-744da14b2a0a), Stack size too large. Stack address: 0x7fb7fddf0000, frame address: 0x7fb7fe1ef100, stack size: 4198144, maximum stack size: 8388608 2025.07.28 11:52:28.439671 [ 17207 ] {843f77fd-10c6-418e-aec8-086925dc7938} PushingToViews: Failed to push block to view test_5.v2 (7c22a887-3ed3-40f1-a092-d92463e4b87b), Stack size too large. Stack address: 0x7fb7fddf0000, frame address: 0x7fb7fe1ef100, stack size: 4198144, maximum stack size: 8388608 2025.07.28 11:52:28.440460 [ 17207 ] {843f77fd-10c6-418e-aec8-086925dc7938} PushingToViews: Failed to push block to view test_5.v1 (4ae2feef-b6fa-47ac-b20c-744da14b2a0a), Stack size too large. Stack address: 0x7fb7fddf0000, frame address: 0x7fb7fe1ef100, stack size: 4198144, maximum stack size: 8388608 2025.07.28 11:52:28.445869 [ 17207 ] {843f77fd-10c6-418e-aec8-086925dc7938} PushingToViews: Failed to push block to view test_5.v2 (7c22a887-3ed3-40f1-a092-d92463e4b87b), Stack size too large. Stack address: 0x7fb7fddf0000, frame address: 0x7fb7fe1ef100, stack size: 4198144, maximum stack size: 8388608 2025.07.28 11:52:28.449080 [ 17207 ] {843f77fd-10c6-418e-aec8-086925dc7938} PushingToViews: Failed to push block to view test_5.v1 (4ae2feef-b6fa-47ac-b20c-744da14b2a0a), Stack size too large. Stack address: 0x7fb7fddf0000, frame address: 0x7fb7fe1ef100, stack size: 4198144, maximum stack size: 8388608 2025.07.28 11:52:28.451029 [ 17207 ] {843f77fd-10c6-418e-aec8-086925dc7938} PushingToViews: Failed to push block to view test_5.v2 (7c22a887-3ed3-40f1-a092-d92463e4b87b), Stack size too large. Stack address: 0x7fb7fddf0000, frame address: 0x7fb7fe1ef100, stack size: 4198144, maximum stack size: 8388608 2025.07.28 11:52:28.456113 [ 17207 ] {843f77fd-10c6-418e-aec8-086925dc7938} PushingToViews: Failed to push block to view test_5.v1 (4ae2feef-b6fa-47ac-b20c-744da14b2a0a), Stack size too large. Stack address: 0x7fb7fddf0000, frame address: 0x7fb7fe1ef100, stack size: 4198144, maximum stack size: 8388608 2025.07.28 11:52:28.457918 [ 17207 ] {843f77fd-10c6-418e-aec8-086925dc7938} PushingToViews: Failed to push block to view test_5.v2 (7c22a887-3ed3-40f1-a092-d92463e4b87b), Stack size too large. Stack address: 0x7fb7fddf0000, frame address: 0x7fb7fe1ef100, stack size: 4198144, maximum stack size: 8388608 2025.07.28 11:52:28.459604 [ 17207 ] {843f77fd-10c6-418e-aec8-086925dc7938} PushingToViews: Failed to push block to view test_5.v1 (4ae2feef-b6fa-47ac-b20c-744da14b2a0a), Stack size too large. Stack address: 0x7fb7fddf0000, frame address: 0x7fb7fe1ef100, stack size: 4198144, maximum stack size: 8388608 2025.07.28 11:52:28.461194 [ 17207 ] {843f77fd-10c6-418e-aec8-086925dc7938} PushingToViews: Failed to push block to view test_5.v2 (7c22a887-3ed3-40f1-a092-d92463e4b87b), Stack size too large. Stack address: 0x7fb7fddf0000, frame address: 0x7fb7fe1ef100, stack size: 4198144, maximum stack size: 8388608 2025.07.28 11:52:28.464086 [ 17207 ] {843f77fd-10c6-418e-aec8-086925dc7938} PushingToViews: Failed to push block to view test_5.v1 (4ae2feef-b6fa-47ac-b20c-744da14b2a0a), Stack size too large. Stack address: 0x7fb7fddf0000, frame address: 0x7fb7fe1ef100, stack size: 4198144, maximum stack size: 8388608 2025.07.28 11:52:28.466343 [ 17207 ] {843f77fd-10c6-418e-aec8-086925dc7938} PushingToViews: Failed to push block to view test_5.v2 (7c22a887-3ed3-40f1-a092-d92463e4b87b), Stack size too large. Stack address: 0x7fb7fddf0000, frame address: 0x7fb7fe1ef100, stack size: 4198144, maximum stack size: 8388608 2025.07.28 11:52:28.467849 [ 17207 ] {843f77fd-10c6-418e-aec8-086925dc7938} PushingToViews: Failed to push block to view test_5.v1 (4ae2feef-b6fa-47ac-b20c-744da14b2a0a), Stack size too large. Stack address: 0x7fb7fddf0000, frame address: 0x7fb7fe1ef100, stack size: 4198144, maximum stack size: 8388608 2025.07.28 11:52:28.470002 [ 17207 ] {843f77fd-10c6-418e-aec8-086925dc7938} PushingToViews: Failed to push block to view test_5.v2 (7c22a887-3ed3-40f1-a092-d92463e4b87b), Stack size too large. Stack address: 0x7fb7fddf0000, frame address: 0x7fb7fe1ef100, stack size: 4198144, maximum stack size: 8388608 2025.07.28 11:52:28.471876 [ 17207 ] {843f77fd-10c6-418e-aec8-086925dc7938} PushingToViews: Failed to push block to view test_5.v1 (4ae2feef-b6fa-47ac-b20c-744da14b2a0a), Stack size too large. Stack address: 0x7fb7fddf0000, frame address: 0x7fb7fe1ef100, stack size: 4198144, maximum stack size: 8388608 2025.07.28 11:52:28.483270 [ 17207 ] {843f77fd-10c6-418e-aec8-086925dc7938} PushingToViews: Failed to push block to view test_5.v2 (7c22a887-3ed3-40f1-a092-d92463e4b87b), Stack size too large. Stack address: 0x7fb7fddf0000, frame address: 0x7fb7fe1ef100, stack size: 4198144, maximum stack size: 8388608 2025.07.28 11:52:28.486012 [ 17207 ] {843f77fd-10c6-418e-aec8-086925dc7938} PushingToViews: Failed to push block to view test_5.v1 (4ae2feef-b6fa-47ac-b20c-744da14b2a0a), Stack size too large. Stack address: 0x7fb7fddf0000, frame address: 0x7fb7fe1ef100, stack size: 4198144, maximum stack size: 8388608 2025.07.28 11:52:28.487974 [ 17207 ] {843f77fd-10c6-418e-aec8-086925dc7938} PushingToViews: Failed to push block to view test_5.v2 (7c22a887-3ed3-40f1-a092-d92463e4b87b), Stack size too large. Stack address: 0x7fb7fddf0000, frame address: 0x7fb7fe1ef100, stack size: 4198144, maximum stack size: 8388608 2025.07.28 11:52:28.489851 [ 17207 ] {843f77fd-10c6-418e-aec8-086925dc7938} PushingToViews: Failed to push block to view test_5.v1 (4ae2feef-b6fa-47ac-b20c-744da14b2a0a), Stack size too large. Stack address: 0x7fb7fddf0000, frame address: 0x7fb7fe1ef100, stack size: 4198144, maximum stack size: 8388608 2025.07.28 11:52:28.492801 [ 17207 ] {843f77fd-10c6-418e-aec8-086925dc7938} PushingToViews: Failed to push block to view test_5.v2 (7c22a887-3ed3-40f1-a092-d92463e4b87b), Stack size too large. Stack address: 0x7fb7fddf0000, frame address: 0x7fb7fe1ef100, stack size: 4198144, maximum stack size: 8388608 2025.07.28 11:52:28.504697 [ 17207 ] {843f77fd-10c6-418e-aec8-086925dc7938} PushingToViews: Failed to push block to view test_5.v1 (4ae2feef-b6fa-47ac-b20c-744da14b2a0a), Stack size too large. Stack address: 0x7fb7fddf0000, frame address: 0x7fb7fe1ef100, stack size: 4198144, maximum stack size: 8388608 2025.07.28 11:52:28.516954 [ 17207 ] {843f77fd-10c6-418e-aec8-086925dc7938} PushingToViews: Failed to push block to view test_5.v2 (7c22a887-3ed3-40f1-a092-d92463e4b87b), Stack size too large. Stack address: 0x7fb7fddf0000, frame address: 0x7fb7fe1ef100, stack size: 4198144, maximum stack size: 8388608 2025.07.28 11:52:28.520813 [ 17207 ] {843f77fd-10c6-418e-aec8-086925dc7938} PushingToViews: Failed to push block to view test_5.v1 (4ae2feef-b6fa-47ac-b20c-744da14b2a0a), Stack size too large. Stack address: 0x7fb7fddf0000, frame address: 0x7fb7fe1ef100, stack size: 4198144, maximum stack size: 8388608 2025.07.28 11:52:28.524309 [ 17207 ] {843f77fd-10c6-418e-aec8-086925dc7938} PushingToViews: Failed to push block to view test_5.v2 (7c22a887-3ed3-40f1-a092-d92463e4b87b), Stack size too large. Stack address: 0x7fb7fddf0000, frame address: 0x7fb7fe1ef100, stack size: 4198144, maximum stack size: 8388608 2025.07.28 11:52:28.527109 [ 17207 ] {843f77fd-10c6-418e-aec8-086925dc7938} PushingToViews: Failed to push block to view test_5.v1 (4ae2feef-b6fa-47ac-b20c-744da14b2a0a), Stack size too large. Stack address: 0x7fb7fddf0000, frame address: 0x7fb7fe1ef100, stack size: 4198144, maximum stack size: 8388608 2025.07.28 11:52:28.529853 [ 17207 ] {843f77fd-10c6-418e-aec8-086925dc7938} PushingToViews: Failed to push block to view test_5.v2 (7c22a887-3ed3-40f1-a092-d92463e4b87b), Stack size too large. Stack address: 0x7fb7fddf0000, frame address: 0x7fb7fe1ef100, stack size: 4198144, maximum stack size: 8388608 2025.07.28 11:52:28.538301 [ 17207 ] {843f77fd-10c6-418e-aec8-086925dc7938} PushingToViews: Failed to push block to view test_5.v1 (4ae2feef-b6fa-47ac-b20c-744da14b2a0a), Stack size too large. Stack address: 0x7fb7fddf0000, frame address: 0x7fb7fe1ef100, stack size: 4198144, maximum stack size: 8388608 2025.07.28 11:52:28.540976 [ 17207 ] {843f77fd-10c6-418e-aec8-086925dc7938} PushingToViews: Failed to push block to view test_5.v2 (7c22a887-3ed3-40f1-a092-d92463e4b87b), Stack size too large. Stack address: 0x7fb7fddf0000, frame address: 0x7fb7fe1ef100, stack size: 4198144, maximum stack size: 8388608 2025.07.28 11:52:28.547795 [ 17207 ] {843f77fd-10c6-418e-aec8-086925dc7938} PushingToViews: Failed to push block to view test_5.v1 (4ae2feef-b6fa-47ac-b20c-744da14b2a0a), Stack size too large. Stack address: 0x7fb7fddf0000, frame address: 0x7fb7fe1ef100, stack size: 4198144, maximum stack size: 8388608 2025.07.28 11:52:28.563190 [ 17207 ] {843f77fd-10c6-418e-aec8-086925dc7938} PushingToViews: Failed to push block to view test_5.v2 (7c22a887-3ed3-40f1-a092-d92463e4b87b), Stack size too large. Stack address: 0x7fb7fddf0000, frame address: 0x7fb7fe1ef100, stack size: 4198144, maximum stack size: 8388608 2025.07.28 11:52:28.572386 [ 17207 ] {843f77fd-10c6-418e-aec8-086925dc7938} PushingToViews: Failed to push block to view test_5.v1 (4ae2feef-b6fa-47ac-b20c-744da14b2a0a), Stack size too large. Stack address: 0x7fb7fddf0000, frame address: 0x7fb7fe1ef100, stack size: 4198144, maximum stack size: 8388608 2025.07.28 11:52:28.574205 [ 17207 ] {843f77fd-10c6-418e-aec8-086925dc7938} PushingToViews: Failed to push block to view test_5.v2 (7c22a887-3ed3-40f1-a092-d92463e4b87b), Stack size too large. Stack address: 0x7fb7fddf0000, frame address: 0x7fb7fe1ef100, stack size: 4198144, maximum stack size: 8388608 2025.07.28 11:52:28.579525 [ 17207 ] {843f77fd-10c6-418e-aec8-086925dc7938} PushingToViews: Failed to push block to view test_5.v1 (4ae2feef-b6fa-47ac-b20c-744da14b2a0a), Stack size too large. Stack address: 0x7fb7fddf0000, frame address: 0x7fb7fe1ef100, stack size: 4198144, maximum stack size: 8388608 2025.07.28 11:52:28.582815 [ 17207 ] {843f77fd-10c6-418e-aec8-086925dc7938} PushingToViews: Failed to push block to view test_5.v2 (7c22a887-3ed3-40f1-a092-d92463e4b87b), Stack size too large. Stack address: 0x7fb7fddf0000, frame address: 0x7fb7fe1ef100, stack size: 4198144, maximum stack size: 8388608 2025.07.28 11:52:28.584081 [ 17207 ] {843f77fd-10c6-418e-aec8-086925dc7938} PushingToViews: Failed to push block to view test_5.v1 (4ae2feef-b6fa-47ac-b20c-744da14b2a0a), Stack size too large. Stack address: 0x7fb7fddf0000, frame address: 0x7fb7fe1ef100, stack size: 4198144, maximum stack size: 8388608 2025.07.28 11:52:28.587794 [ 17207 ] {843f77fd-10c6-418e-aec8-086925dc7938} PushingToViews: Failed to push block to view test_5.v2 (7c22a887-3ed3-40f1-a092-d92463e4b87b), Stack size too large. Stack address: 0x7fb7fddf0000, frame address: 0x7fb7fe1ef100, stack size: 4198144, maximum stack size: 8388608 2025.07.28 11:52:28.590307 [ 17207 ] {843f77fd-10c6-418e-aec8-086925dc7938} PushingToViews: Failed to push block to view test_5.v1 (4ae2feef-b6fa-47ac-b20c-744da14b2a0a), Stack size too large. Stack address: 0x7fb7fddf0000, frame address: 0x7fb7fe1ef100, stack size: 4198144, maximum stack size: 8388608 2025.07.28 11:52:28.592498 [ 17207 ] {843f77fd-10c6-418e-aec8-086925dc7938} PushingToViews: Failed to push block to view test_5.v2 (7c22a887-3ed3-40f1-a092-d92463e4b87b), Stack size too large. Stack address: 0x7fb7fddf0000, frame address: 0x7fb7fe1ef100, stack size: 4198144, maximum stack size: 8388608 2025.07.28 11:52:28.608020 [ 17207 ] {843f77fd-10c6-418e-aec8-086925dc7938} PushingToViews: Failed to push block to view test_5.v1 (4ae2feef-b6fa-47ac-b20c-744da14b2a0a), Stack size too large. Stack address: 0x7fb7fddf0000, frame address: 0x7fb7fe1ef100, stack size: 4198144, maximum stack size: 8388608 2025.07.28 11:52:28.610025 [ 17207 ] {843f77fd-10c6-418e-aec8-086925dc7938} PushingToViews: Failed to push block to view test_5.v2 (7c22a887-3ed3-40f1-a092-d92463e4b87b), Stack size too large. Stack address: 0x7fb7fddf0000, frame address: 0x7fb7fe1ef100, stack size: 4198144, maximum stack size: 8388608 2025.07.28 11:52:28.613253 [ 17207 ] {843f77fd-10c6-418e-aec8-086925dc7938} PushingToViews: Failed to push block to view test_5.v1 (4ae2feef-b6fa-47ac-b20c-744da14b2a0a), Stack size too large. Stack address: 0x7fb7fddf0000, frame address: 0x7fb7fe1ef100, stack size: 4198144, maximum stack size: 8388608 2025.07.28 11:52:28.615303 [ 17207 ] {843f77fd-10c6-418e-aec8-086925dc7938} PushingToViews: Failed to push block to view test_5.v2 (7c22a887-3ed3-40f1-a092-d92463e4b87b), Stack size too large. Stack address: 0x7fb7fddf0000, frame address: 0x7fb7fe1ef100, stack size: 4198144, maximum stack size: 8388608 2025.07.28 11:52:28.616964 [ 17207 ] {843f77fd-10c6-418e-aec8-086925dc7938} PushingToViews: Failed to push block to view test_5.v1 (4ae2feef-b6fa-47ac-b20c-744da14b2a0a), Stack size too large. Stack address: 0x7fb7fddf0000, frame address: 0x7fb7fe1ef100, stack size: 4198144, maximum stack size: 8388608 2025.07.28 11:52:28.628566 [ 17207 ] {843f77fd-10c6-418e-aec8-086925dc7938} PushingToViews: Failed to push block to view test_5.v2 (7c22a887-3ed3-40f1-a092-d92463e4b87b), Stack size too large. Stack address: 0x7fb7fddf0000, frame address: 0x7fb7fe1ef100, stack size: 4198144, maximum stack size: 8388608 2025.07.28 11:52:28.631082 [ 17207 ] {843f77fd-10c6-418e-aec8-086925dc7938} PushingToViews: Failed to push block to view test_5.v1 (4ae2feef-b6fa-47ac-b20c-744da14b2a0a), Stack size too large. Stack address: 0x7fb7fddf0000, frame address: 0x7fb7fe1ef100, stack size: 4198144, maximum stack size: 8388608 2025.07.28 11:52:28.637226 [ 17207 ] {843f77fd-10c6-418e-aec8-086925dc7938} PushingToViews: Failed to push block to view test_5.v2 (7c22a887-3ed3-40f1-a092-d92463e4b87b), Stack size too large. Stack address: 0x7fb7fddf0000, frame address: 0x7fb7fe1ef100, stack size: 4198144, maximum stack size: 8388608 2025.07.28 11:52:28.668092 [ 17207 ] {843f77fd-10c6-418e-aec8-086925dc7938} PushingToViews: Failed to push block to view test_5.v1 (4ae2feef-b6fa-47ac-b20c-744da14b2a0a), Stack size too large. Stack address: 0x7fb7fddf0000, frame address: 0x7fb7fe1ef100, stack size: 4198144, maximum stack size: 8388608 2025.07.28 11:52:28.671245 [ 17207 ] {843f77fd-10c6-418e-aec8-086925dc7938} PushingToViews: Failed to push block to view test_5.v2 (7c22a887-3ed3-40f1-a092-d92463e4b87b), Stack size too large. Stack address: 0x7fb7fddf0000, frame address: 0x7fb7fe1ef100, stack size: 4198144, maximum stack size: 8388608 2025.07.28 11:52:28.673371 [ 17207 ] {843f77fd-10c6-418e-aec8-086925dc7938} PushingToViews: Failed to push block to view test_5.v1 (4ae2feef-b6fa-47ac-b20c-744da14b2a0a), Stack size too large. Stack address: 0x7fb7fddf0000, frame address: 0x7fb7fe1ef100, stack size: 4198144, maximum stack size: 8388608 2025.07.28 11:52:28.676660 [ 17207 ] {843f77fd-10c6-418e-aec8-086925dc7938} PushingToViews: Failed to push block to view test_5.v2 (7c22a887-3ed3-40f1-a092-d92463e4b87b), Stack size too large. Stack address: 0x7fb7fddf0000, frame address: 0x7fb7fe1ef100, stack size: 4198144, maximum stack size: 8388608 2025.07.28 11:52:28.679050 [ 17207 ] {843f77fd-10c6-418e-aec8-086925dc7938} PushingToViews: Failed to push block to view test_5.v1 (4ae2feef-b6fa-47ac-b20c-744da14b2a0a), Stack size too large. Stack address: 0x7fb7fddf0000, frame address: 0x7fb7fe1ef100, stack size: 4198144, maximum stack size: 8388608 2025.07.28 11:52:28.680230 [ 17207 ] {843f77fd-10c6-418e-aec8-086925dc7938} PushingToViews: Failed to push block to view test_5.v2 (7c22a887-3ed3-40f1-a092-d92463e4b87b), Stack size too large. Stack address: 0x7fb7fddf0000, frame address: 0x7fb7fe1ef100, stack size: 4198144, maximum stack size: 8388608 2025.07.28 11:52:28.682801 [ 17207 ] {843f77fd-10c6-418e-aec8-086925dc7938} PushingToViews: Failed to push block to view test_5.v1 (4ae2feef-b6fa-47ac-b20c-744da14b2a0a), Stack size too large. Stack address: 0x7fb7fddf0000, frame address: 0x7fb7fe1ef100, stack size: 4198144, maximum stack size: 8388608 2025.07.28 11:52:28.684411 [ 17207 ] {843f77fd-10c6-418e-aec8-086925dc7938} PushingToViews: Failed to push block to view test_5.v2 (7c22a887-3ed3-40f1-a092-d92463e4b87b), Stack size too large. Stack address: 0x7fb7fddf0000, frame address: 0x7fb7fe1ef100, stack size: 4198144, maximum stack size: 8388608 2025.07.28 11:52:28.686389 [ 17207 ] {843f77fd-10c6-418e-aec8-086925dc7938} PushingToViews: Failed to push block to view test_5.v1 (4ae2feef-b6fa-47ac-b20c-744da14b2a0a), Stack size too large. Stack address: 0x7fb7fddf0000, frame address: 0x7fb7fe1ef100, stack size: 4198144, maximum stack size: 8388608 2025.07.28 11:52:28.695351 [ 17207 ] {843f77fd-10c6-418e-aec8-086925dc7938} PushingToViews: Failed to push block to view test_5.v2 (7c22a887-3ed3-40f1-a092-d92463e4b87b), Stack size too large. Stack address: 0x7fb7fddf0000, frame address: 0x7fb7fe1ef100, stack size: 4198144, maximum stack size: 8388608 2025.07.28 11:52:28.709303 [ 17207 ] {843f77fd-10c6-418e-aec8-086925dc7938} PushingToViews: Failed to push block to view test_5.v1 (4ae2feef-b6fa-47ac-b20c-744da14b2a0a), Stack size too large. Stack address: 0x7fb7fddf0000, frame address: 0x7fb7fe1ef100, stack size: 4198144, maximum stack size: 8388608 2025.07.28 11:52:28.711539 [ 17207 ] {843f77fd-10c6-418e-aec8-086925dc7938} PushingToViews: Failed to push block to view test_5.v2 (7c22a887-3ed3-40f1-a092-d92463e4b87b), Stack size too large. Stack address: 0x7fb7fddf0000, frame address: 0x7fb7fe1ef100, stack size: 4198144, maximum stack size: 8388608 2025.07.28 11:52:28.712967 [ 17207 ] {843f77fd-10c6-418e-aec8-086925dc7938} PushingToViews: Failed to push block to view test_5.v1 (4ae2feef-b6fa-47ac-b20c-744da14b2a0a), Stack size too large. Stack address: 0x7fb7fddf0000, frame address: 0x7fb7fe1ef100, stack size: 4198144, maximum stack size: 8388608 2025.07.28 11:52:28.716960 [ 17207 ] {843f77fd-10c6-418e-aec8-086925dc7938} PushingToViews: Failed to push block to view test_5.v2 (7c22a887-3ed3-40f1-a092-d92463e4b87b), Stack size too large. Stack address: 0x7fb7fddf0000, frame address: 0x7fb7fe1ef100, stack size: 4198144, maximum stack size: 8388608 2025.07.28 11:52:28.718787 [ 17207 ] {843f77fd-10c6-418e-aec8-086925dc7938} PushingToViews: Failed to push block to view test_5.v1 (4ae2feef-b6fa-47ac-b20c-744da14b2a0a), Stack size too large. Stack address: 0x7fb7fddf0000, frame address: 0x7fb7fe1ef100, stack size: 4198144, maximum stack size: 8388608 2025.07.28 11:52:28.720373 [ 17207 ] {843f77fd-10c6-418e-aec8-086925dc7938} PushingToViews: Failed to push block to view test_5.v2 (7c22a887-3ed3-40f1-a092-d92463e4b87b), Stack size too large. Stack address: 0x7fb7fddf0000, frame address: 0x7fb7fe1ef100, stack size: 4198144, maximum stack size: 8388608 2025.07.28 11:52:28.723981 [ 17207 ] {843f77fd-10c6-418e-aec8-086925dc7938} PushingToViews: Failed to push block to view test_5.v1 (4ae2feef-b6fa-47ac-b20c-744da14b2a0a), Stack size too large. Stack address: 0x7fb7fddf0000, frame address: 0x7fb7fe1ef100, stack size: 4198144, maximum stack size: 8388608 2025.07.28 11:52:28.731423 [ 17207 ] {843f77fd-10c6-418e-aec8-086925dc7938} PushingToViews: Failed to push block to view test_5.v2 (7c22a887-3ed3-40f1-a092-d92463e4b87b), Stack size too large. Stack address: 0x7fb7fddf0000, frame address: 0x7fb7fe1ef100, stack size: 4198144, maximum stack size: 8388608 2025.07.28 11:52:28.740703 [ 17207 ] {843f77fd-10c6-418e-aec8-086925dc7938} PushingToViews: Failed to push block to view test_5.v1 (4ae2feef-b6fa-47ac-b20c-744da14b2a0a), Stack size too large. Stack address: 0x7fb7fddf0000, frame address: 0x7fb7fe1ef100, stack size: 4198144, maximum stack size: 8388608 2025.07.28 11:52:28.742981 [ 17207 ] {843f77fd-10c6-418e-aec8-086925dc7938} PushingToViews: Failed to push block to view test_5.v2 (7c22a887-3ed3-40f1-a092-d92463e4b87b), Stack size too large. Stack address: 0x7fb7fddf0000, frame address: 0x7fb7fe1ef100, stack size: 4198144, maximum stack size: 8388608 2025.07.28 11:52:28.746115 [ 17207 ] {843f77fd-10c6-418e-aec8-086925dc7938} PushingToViews: Failed to push block to view test_5.v1 (4ae2feef-b6fa-47ac-b20c-744da14b2a0a), Stack size too large. Stack address: 0x7fb7fddf0000, frame address: 0x7fb7fe1ef100, stack size: 4198144, maximum stack size: 8388608 2025.07.28 11:52:28.748879 [ 17207 ] {843f77fd-10c6-418e-aec8-086925dc7938} PushingToViews: Failed to push block to view test_5.v2 (7c22a887-3ed3-40f1-a092-d92463e4b87b), Stack size too large. Stack address: 0x7fb7fddf0000, frame address: 0x7fb7fe1ef100, stack size: 4198144, maximum stack size: 8388608 2025.07.28 11:52:28.750710 [ 17207 ] {843f77fd-10c6-418e-aec8-086925dc7938} PushingToViews: Failed to push block to view test_5.v1 (4ae2feef-b6fa-47ac-b20c-744da14b2a0a), Stack size too large. Stack address: 0x7fb7fddf0000, frame address: 0x7fb7fe1ef100, stack size: 4198144, maximum stack size: 8388608 2025.07.28 11:52:28.752806 [ 17207 ] {843f77fd-10c6-418e-aec8-086925dc7938} PushingToViews: Failed to push block to view test_5.v2 (7c22a887-3ed3-40f1-a092-d92463e4b87b), Stack size too large. Stack address: 0x7fb7fddf0000, frame address: 0x7fb7fe1ef100, stack size: 4198144, maximum stack size: 8388608 2025.07.28 11:52:28.754635 [ 17207 ] {843f77fd-10c6-418e-aec8-086925dc7938} PushingToViews: Failed to push block to view test_5.v1 (4ae2feef-b6fa-47ac-b20c-744da14b2a0a), Stack size too large. Stack address: 0x7fb7fddf0000, frame address: 0x7fb7fe1ef100, stack size: 4198144, maximum stack size: 8388608 2025.07.28 11:52:28.757102 [ 17207 ] {843f77fd-10c6-418e-aec8-086925dc7938} PushingToViews: Failed to push block to view test_5.v2 (7c22a887-3ed3-40f1-a092-d92463e4b87b), Stack size too large. Stack address: 0x7fb7fddf0000, frame address: 0x7fb7fe1ef100, stack size: 4198144, maximum stack size: 8388608 2025.07.28 11:52:28.770842 [ 17207 ] {843f77fd-10c6-418e-aec8-086925dc7938} PushingToViews: Failed to push block to view test_5.v1 (4ae2feef-b6fa-47ac-b20c-744da14b2a0a), Stack size too large. Stack address: 0x7fb7fddf0000, frame address: 0x7fb7fe1ef100, stack size: 4198144, maximum stack size: 8388608 2025.07.28 11:52:28.772915 [ 17207 ] {843f77fd-10c6-418e-aec8-086925dc7938} PushingToViews: Failed to push block to view test_5.v2 (7c22a887-3ed3-40f1-a092-d92463e4b87b), Stack size too large. Stack address: 0x7fb7fddf0000, frame address: 0x7fb7fe1ef100, stack size: 4198144, maximum stack size: 8388608 2025.07.28 11:52:28.782166 [ 17207 ] {843f77fd-10c6-418e-aec8-086925dc7938} PushingToViews: Failed to push block to view test_5.v1 (4ae2feef-b6fa-47ac-b20c-744da14b2a0a), Stack size too large. Stack address: 0x7fb7fddf0000, frame address: 0x7fb7fe1ef100, stack size: 4198144, maximum stack size: 8388608 2025.07.28 11:52:28.785248 [ 17207 ] {843f77fd-10c6-418e-aec8-086925dc7938} PushingToViews: Failed to push block to view test_5.v2 (7c22a887-3ed3-40f1-a092-d92463e4b87b), Stack size too large. Stack address: 0x7fb7fddf0000, frame address: 0x7fb7fe1ef100, stack size: 4198144, maximum stack size: 8388608 2025.07.28 11:52:28.796221 [ 17207 ] {843f77fd-10c6-418e-aec8-086925dc7938} PushingToViews: Failed to push block to view test_5.v1 (4ae2feef-b6fa-47ac-b20c-744da14b2a0a), Stack size too large. Stack address: 0x7fb7fddf0000, frame address: 0x7fb7fe1ef100, stack size: 4198144, maximum stack size: 8388608 2025.07.28 11:52:28.802384 [ 17207 ] {843f77fd-10c6-418e-aec8-086925dc7938} PushingToViews: Failed to push block to view test_5.v2 (7c22a887-3ed3-40f1-a092-d92463e4b87b), Stack size too large. Stack address: 0x7fb7fddf0000, frame address: 0x7fb7fe1ef100, stack size: 4198144, maximum stack size: 8388608 2025.07.28 11:52:28.811390 [ 17207 ] {843f77fd-10c6-418e-aec8-086925dc7938} PushingToViews: Failed to push block to view test_5.v1 (4ae2feef-b6fa-47ac-b20c-744da14b2a0a), Stack size too large. Stack address: 0x7fb7fddf0000, frame address: 0x7fb7fe1ef100, stack size: 4198144, maximum stack size: 8388608 2025.07.28 11:52:28.830615 [ 17207 ] {843f77fd-10c6-418e-aec8-086925dc7938} PushingToViews: Failed to push block to view test_5.v2 (7c22a887-3ed3-40f1-a092-d92463e4b87b), Stack size too large. Stack address: 0x7fb7fddf0000, frame address: 0x7fb7fe1ef100, stack size: 4198144, maximum stack size: 8388608 2025.07.28 11:52:28.845587 [ 17207 ] {843f77fd-10c6-418e-aec8-086925dc7938} PushingToViews: Failed to push block to view test_5.v1 (4ae2feef-b6fa-47ac-b20c-744da14b2a0a), Stack size too large. Stack address: 0x7fb7fddf0000, frame address: 0x7fb7fe1ef100, stack size: 4198144, maximum stack size: 8388608 2025.07.28 11:52:28.846677 [ 17207 ] {843f77fd-10c6-418e-aec8-086925dc7938} PushingToViews: Failed to push block to view test_5.v2 (7c22a887-3ed3-40f1-a092-d92463e4b87b), Stack size too large. Stack address: 0x7fb7fddf0000, frame address: 0x7fb7fe1ef100, stack size: 4198144, maximum stack size: 8388608 2025.07.28 11:52:28.849162 [ 17207 ] {843f77fd-10c6-418e-aec8-086925dc7938} PushingToViews: Failed to push block to view test_5.v1 (4ae2feef-b6fa-47ac-b20c-744da14b2a0a), Stack size too large. Stack address: 0x7fb7fddf0000, frame address: 0x7fb7fe1ef100, stack size: 4198144, maximum stack size: 8388608 2025.07.28 11:52:28.852666 [ 17207 ] {843f77fd-10c6-418e-aec8-086925dc7938} PushingToViews: Failed to push block to view test_5.v2 (7c22a887-3ed3-40f1-a092-d92463e4b87b), Stack size too large. Stack address: 0x7fb7fddf0000, frame address: 0x7fb7fe1ef100, stack size: 4198144, maximum stack size: 8388608 2025.07.28 11:52:28.854606 [ 17207 ] {843f77fd-10c6-418e-aec8-086925dc7938} PushingToViews: Failed to push block to view test_5.v1 (4ae2feef-b6fa-47ac-b20c-744da14b2a0a), Stack size too large. Stack address: 0x7fb7fddf0000, frame address: 0x7fb7fe1ef100, stack size: 4198144, maximum stack size: 8388608 2025.07.28 11:52:28.857407 [ 17207 ] {843f77fd-10c6-418e-aec8-086925dc7938} PushingToViews: Failed to push block to view test_5.v2 (7c22a887-3ed3-40f1-a092-d92463e4b87b), Stack size too large. Stack address: 0x7fb7fddf0000, frame address: 0x7fb7fe1ef100, stack size: 4198144, maximum stack size: 8388608 2025.07.28 11:52:28.862813 [ 17207 ] {843f77fd-10c6-418e-aec8-086925dc7938} PushingToViews: Failed to push block to view test_5.v1 (4ae2feef-b6fa-47ac-b20c-744da14b2a0a), Stack size too large. Stack address: 0x7fb7fddf0000, frame address: 0x7fb7fe1ef100, stack size: 4198144, maximum stack size: 8388608 2025.07.28 11:52:28.864343 [ 17207 ] {843f77fd-10c6-418e-aec8-086925dc7938} PushingToViews: Failed to push block to view test_5.v2 (7c22a887-3ed3-40f1-a092-d92463e4b87b), Stack size too large. Stack address: 0x7fb7fddf0000, frame address: 0x7fb7fe1ef100, stack size: 4198144, maximum stack size: 8388608 2025.07.28 11:52:28.868570 [ 17207 ] {843f77fd-10c6-418e-aec8-086925dc7938} PushingToViews: Failed to push block to view test_5.v1 (4ae2feef-b6fa-47ac-b20c-744da14b2a0a), Stack size too large. Stack address: 0x7fb7fddf0000, frame address: 0x7fb7fe1ef100, stack size: 4198144, maximum stack size: 8388608 2025.07.28 11:52:28.881060 [ 17207 ] {843f77fd-10c6-418e-aec8-086925dc7938} PushingToViews: Failed to push block to view test_5.v2 (7c22a887-3ed3-40f1-a092-d92463e4b87b), Stack size too large. Stack address: 0x7fb7fddf0000, frame address: 0x7fb7fe1ef100, stack size: 4198144, maximum stack size: 8388608 2025.07.28 11:52:28.882631 [ 17207 ] {843f77fd-10c6-418e-aec8-086925dc7938} PushingToViews: Failed to push block to view test_5.v1 (4ae2feef-b6fa-47ac-b20c-744da14b2a0a), Stack size too large. Stack address: 0x7fb7fddf0000, frame address: 0x7fb7fe1ef100, stack size: 4198144, maximum stack size: 8388608 2025.07.28 11:52:28.898945 [ 17207 ] {843f77fd-10c6-418e-aec8-086925dc7938} PushingToViews: Failed to push block to view test_5.v2 (7c22a887-3ed3-40f1-a092-d92463e4b87b), Stack size too large. Stack address: 0x7fb7fddf0000, frame address: 0x7fb7fe1ef100, stack size: 4198144, maximum stack size: 8388608 2025.07.28 11:52:28.902622 [ 17207 ] {843f77fd-10c6-418e-aec8-086925dc7938} PushingToViews: Failed to push block to view test_5.v1 (4ae2feef-b6fa-47ac-b20c-744da14b2a0a), Stack size too large. Stack address: 0x7fb7fddf0000, frame address: 0x7fb7fe1ef100, stack size: 4198144, maximum stack size: 8388608 2025.07.28 11:52:28.903979 [ 17207 ] {843f77fd-10c6-418e-aec8-086925dc7938} PushingToViews: Failed to push block to view test_5.v2 (7c22a887-3ed3-40f1-a092-d92463e4b87b), Stack size too large. Stack address: 0x7fb7fddf0000, frame address: 0x7fb7fe1ef100, stack size: 4198144, maximum stack size: 8388608 2025.07.28 11:52:28.907767 [ 17207 ] {843f77fd-10c6-418e-aec8-086925dc7938} PushingToViews: Failed to push block to view test_5.v1 (4ae2feef-b6fa-47ac-b20c-744da14b2a0a), Stack size too large. Stack address: 0x7fb7fddf0000, frame address: 0x7fb7fe1ef100, stack size: 4198144, maximum stack size: 8388608 2025.07.28 11:52:28.909553 [ 17207 ] {843f77fd-10c6-418e-aec8-086925dc7938} PushingToViews: Failed to push block to view test_5.v2 (7c22a887-3ed3-40f1-a092-d92463e4b87b), Stack size too large. Stack address: 0x7fb7fddf0000, frame address: 0x7fb7fe1ef100, stack size: 4198144, maximum stack size: 8388608 2025.07.28 11:52:28.912316 [ 17207 ] {843f77fd-10c6-418e-aec8-086925dc7938} PushingToViews: Failed to push block to view test_5.v1 (4ae2feef-b6fa-47ac-b20c-744da14b2a0a), Stack size too large. Stack address: 0x7fb7fddf0000, frame address: 0x7fb7fe1ef100, stack size: 4198144, maximum stack size: 8388608 2025.07.28 11:52:28.913725 [ 17207 ] {843f77fd-10c6-418e-aec8-086925dc7938} PushingToViews: Failed to push block to view test_5.v2 (7c22a887-3ed3-40f1-a092-d92463e4b87b), Stack size too large. Stack address: 0x7fb7fddf0000, frame address: 0x7fb7fe1ef100, stack size: 4198144, maximum stack size: 8388608 2025.07.28 11:52:28.951440 [ 12807 ] {df66833e-d6f2-4c13-bc5c-e3c27fa6128c} test_13.alter_table0 (d9d10d50-2ce9-41b4-bbf8-b86fcdd19efe): Cannot rename parts to perform operation on them: Code: 521. DB::ErrnoException: Paths cannot be exchanged because /var/lib/clickhouse/store/d9d/d9d10d50-2ce9-41b4-bbf8-b86fcdd19efe/detached/all_86_86_0 or /var/lib/clickhouse/store/d9d/d9d10d50-2ce9-41b4-bbf8-b86fcdd19efe/detached/attaching_all_86_86_0 does not exist: , errno: 2, strerror: No such file or directory. (ATOMIC_RENAME_FAIL) (version 25.3.6.10636.altinitytest (altinity build)) 2025.07.28 11:52:28.952856 [ 17207 ] {843f77fd-10c6-418e-aec8-086925dc7938} PushingToViews: Failed to push block to view test_5.v1 (4ae2feef-b6fa-47ac-b20c-744da14b2a0a), Stack size too large. Stack address: 0x7fb7fddf0000, frame address: 0x7fb7fe1ef100, stack size: 4198144, maximum stack size: 8388608 2025.07.28 11:52:28.956470 [ 17207 ] {843f77fd-10c6-418e-aec8-086925dc7938} PushingToViews: Failed to push block to view test_5.v2 (7c22a887-3ed3-40f1-a092-d92463e4b87b), Stack size too large. Stack address: 0x7fb7fddf0000, frame address: 0x7fb7fe1ef100, stack size: 4198144, maximum stack size: 8388608 2025.07.28 11:52:28.963011 [ 17207 ] {843f77fd-10c6-418e-aec8-086925dc7938} PushingToViews: Failed to push block to view test_5.v1 (4ae2feef-b6fa-47ac-b20c-744da14b2a0a), Stack size too large. Stack address: 0x7fb7fddf0000, frame address: 0x7fb7fe1ef100, stack size: 4198144, maximum stack size: 8388608 2025.07.28 11:52:28.965390 [ 17207 ] {843f77fd-10c6-418e-aec8-086925dc7938} PushingToViews: Failed to push block to view test_5.v2 (7c22a887-3ed3-40f1-a092-d92463e4b87b), Stack size too large. Stack address: 0x7fb7fddf0000, frame address: 0x7fb7fe1ef100, stack size: 4198144, maximum stack size: 8388608 2025.07.28 11:52:28.972131 [ 17207 ] {843f77fd-10c6-418e-aec8-086925dc7938} PushingToViews: Failed to push block to view test_5.v1 (4ae2feef-b6fa-47ac-b20c-744da14b2a0a), Stack size too large. Stack address: 0x7fb7fddf0000, frame address: 0x7fb7fe1ef100, stack size: 4198144, maximum stack size: 8388608 2025.07.28 11:52:28.974760 [ 17207 ] {843f77fd-10c6-418e-aec8-086925dc7938} PushingToViews: Failed to push block to view test_5.v2 (7c22a887-3ed3-40f1-a092-d92463e4b87b), Stack size too large. Stack address: 0x7fb7fddf0000, frame address: 0x7fb7fe1ef100, stack size: 4198144, maximum stack size: 8388608 2025.07.28 11:52:28.976401 [ 17207 ] {843f77fd-10c6-418e-aec8-086925dc7938} PushingToViews: Failed to push block to view test_5.v1 (4ae2feef-b6fa-47ac-b20c-744da14b2a0a), Stack size too large. Stack address: 0x7fb7fddf0000, frame address: 0x7fb7fe1ef100, stack size: 4198144, maximum stack size: 8388608 2025.07.28 11:52:28.979418 [ 17207 ] {843f77fd-10c6-418e-aec8-086925dc7938} PushingToViews: Failed to push block to view test_5.v2 (7c22a887-3ed3-40f1-a092-d92463e4b87b), Stack size too large. Stack address: 0x7fb7fddf0000, frame address: 0x7fb7fe1ef100, stack size: 4198144, maximum stack size: 8388608 2025.07.28 11:52:29.007064 [ 3968 ] {} test_13.rmt2 (7f9b740d-015c-470e-8cc6-8ba33be0dc63): auto DB::StorageReplicatedMergeTree::processQueueEntry(ReplicatedMergeTreeQueue::SelectedEntryPtr)::(anonymous class)::operator()(LogEntryPtr &) const: Code: 86. DB::HTTPException: Received error from remote server http://146b4357c08d:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Ftest%2F01165%2Ftest_13%2Frmt%2Freplicas%2F1&part=20250728_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.6.10636.altinitytest (altinity build)) '. (RECEIVED_ERROR_FROM_REMOTE_IO_SERVER), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.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 const&, int&&, String const&, unsigned long&&, String const&) @ 0x000000000feda8d9 4. /build/src/IO/HTTPCommon.cpp:104: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x000000000feda6e2 5. /build/src/IO/HTTPCommon.cpp:93: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x000000000feda537 6. /build/src/IO/ReadWriteBufferFromHTTP.cpp:277: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x000000001184a4c4 7. /build/src/IO/ReadWriteBufferFromHTTP.cpp:285: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x000000001184a615 8. /build/src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x000000001184ae59 9. /build/src/IO/ReadWriteBufferFromHTTP.cpp:472: void std::__function::__policy_invoker::__call_impl[abi:se190107]>(std::__function::__policy_storage const*) @ 0x000000001184cedd 10. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001184858b 11. /build/src/IO/ReadWriteBufferFromHTTP.cpp:465: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x000000001184bf0b 12. /build/src/IO/ReadBuffer.h:60: DB::ReadBuffer::next() @ 0x000000000a148c7b 13. /build/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) @ 0x0000000011849fb2 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]>&)>&, 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&) @ 0x0000000011841980 15. /build/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) @ 0x000000001621208e 16. /build/src/Storages/StorageReplicatedMergeTree.cpp:5228: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl[abi:se190107] const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000015f9a5fe 17. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000015ed8bfd 18. /build/src/Storages/StorageReplicatedMergeTree.cpp:2514: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x0000000015ec9aab 19. /build/src/Storages/StorageReplicatedMergeTree.cpp:2349: DB::StorageReplicatedMergeTree::executeLogEntry(DB::ReplicatedMergeTreeLogEntry&) @ 0x0000000015eba91b 20. /build/src/Storages/StorageReplicatedMergeTree.cpp:3876: bool std::__function::__policy_invoker&)>::__call_impl[abi:se190107])::$_1, bool (std::shared_ptr&)>>(std::__function::__policy_storage const*, std::shared_ptr&) @ 0x0000000015f9837e 21. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000165d6fc3 22. /build/src/Storages/StorageReplicatedMergeTree.cpp:3872: DB::StorageReplicatedMergeTree::processQueueEntry(std::shared_ptr) @ 0x0000000015efc18a 23. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001624c1b2 24. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000162f9c70 25. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x00000000162fa55a 26. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc6653 27. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000000fccc4c3 28. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc3d92 29. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fcca080 30. ? @ 0x00007fbc6213eac3 31. ? @ 0x00007fbc621d0850 (version 25.3.6.10636.altinitytest (altinity build)) 2025.07.28 11:52:29.026840 [ 17207 ] {843f77fd-10c6-418e-aec8-086925dc7938} PushingToViews: Failed to push block to view test_5.v1 (4ae2feef-b6fa-47ac-b20c-744da14b2a0a), Stack size too large. Stack address: 0x7fb7fddf0000, frame address: 0x7fb7fe1ef100, stack size: 4198144, maximum stack size: 8388608 2025.07.28 11:52:29.033330 [ 17207 ] {843f77fd-10c6-418e-aec8-086925dc7938} PushingToViews: Failed to push block to view test_5.v2 (7c22a887-3ed3-40f1-a092-d92463e4b87b), Stack size too large. Stack address: 0x7fb7fddf0000, frame address: 0x7fb7fe1ef100, stack size: 4198144, maximum stack size: 8388608 2025.07.28 11:52:29.038681 [ 17207 ] {843f77fd-10c6-418e-aec8-086925dc7938} PushingToViews: Failed to push block to view test_5.v1 (4ae2feef-b6fa-47ac-b20c-744da14b2a0a), Stack size too large. Stack address: 0x7fb7fddf0000, frame address: 0x7fb7fe1ef100, stack size: 4198144, maximum stack size: 8388608 2025.07.28 11:52:29.040324 [ 17207 ] {843f77fd-10c6-418e-aec8-086925dc7938} PushingToViews: Failed to push block to view test_5.v2 (7c22a887-3ed3-40f1-a092-d92463e4b87b), Stack size too large. Stack address: 0x7fb7fddf0000, frame address: 0x7fb7fe1ef100, stack size: 4198144, maximum stack size: 8388608 2025.07.28 11:52:29.056148 [ 17207 ] {843f77fd-10c6-418e-aec8-086925dc7938} PushingToViews: Failed to push block to view test_5.v1 (4ae2feef-b6fa-47ac-b20c-744da14b2a0a), Stack size too large. Stack address: 0x7fb7fddf0000, frame address: 0x7fb7fe1ef100, stack size: 4198144, maximum stack size: 8388608 2025.07.28 11:52:29.063437 [ 17207 ] {843f77fd-10c6-418e-aec8-086925dc7938} PushingToViews: Failed to push block to view test_5.v2 (7c22a887-3ed3-40f1-a092-d92463e4b87b), Stack size too large. Stack address: 0x7fb7fddf0000, frame address: 0x7fb7fe1ef100, stack size: 4198144, maximum stack size: 8388608 2025.07.28 11:52:29.077409 [ 17207 ] {843f77fd-10c6-418e-aec8-086925dc7938} PushingToViews: Failed to push block to view test_5.v1 (4ae2feef-b6fa-47ac-b20c-744da14b2a0a), Stack size too large. Stack address: 0x7fb7fddf0000, frame address: 0x7fb7fe1ef100, stack size: 4198144, maximum stack size: 8388608 2025.07.28 11:52:29.078615 [ 17207 ] {843f77fd-10c6-418e-aec8-086925dc7938} PushingToViews: Failed to push block to view test_5.v2 (7c22a887-3ed3-40f1-a092-d92463e4b87b), Stack size too large. Stack address: 0x7fb7fddf0000, frame address: 0x7fb7fe1ef100, stack size: 4198144, maximum stack size: 8388608 2025.07.28 11:52:29.079695 [ 12807 ] {df66833e-d6f2-4c13-bc5c-e3c27fa6128c} executeQuery: Code: 521. DB::ErrnoException: Paths cannot be exchanged because /var/lib/clickhouse/store/d9d/d9d10d50-2ce9-41b4-bbf8-b86fcdd19efe/detached/all_86_86_0 or /var/lib/clickhouse/store/d9d/d9d10d50-2ce9-41b4-bbf8-b86fcdd19efe/detached/attaching_all_86_86_0 does not exist: , errno: 2, strerror: No such file or directory. (ATOMIC_RENAME_FAIL) (version 25.3.6.10636.altinitytest (altinity build)) (from [::1]:57624) (comment: 02443_detach_attach_partition.sh) (query 1, line 1) (in query: ALTER TABLE alter_table0 ATTACH PARTITION ID 'all';), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:216: DB::ErrnoException::ErrnoException(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String const&) @ 0x0000000013d5fbee 4. /build/src/Common/atomicRename.cpp:97: DB::renameat2(String const&, String const&, int) @ 0x0000000013d5fab0 5. /build/src/Common/atomicRename.cpp:227: DB::renameNoReplace(String const&, String const&) @ 0x0000000013d5f5ba 6. /build/src/Disks/DiskLocal.cpp:318: DB::DiskLocal::moveFile(String const&, String const&) @ 0x0000000013eb1b1e 7. /build/src/Storages/MergeTree/MergeTreeData.cpp:4093: DB::MergeTreeData::PartsTemporaryRename::tryRenameAll() @ 0x000000001633f3c1 8. /build/src/Storages/MergeTree/MergeTreeData.cpp:6783: DB::MergeTreeData::tryLoadPartsToAttach(std::shared_ptr const&, bool, std::shared_ptr, DB::MergeTreeData::PartsTemporaryRename&) @ 0x00000000163646bc 9. /build/src/Storages/StorageReplicatedMergeTree.cpp:6954: DB::StorageReplicatedMergeTree::attachPartition(std::shared_ptr const&, std::shared_ptr const&, bool, std::shared_ptr) @ 0x0000000015f318a4 10. /build/src/Storages/MergeTree/MergeTreeData.cpp:5706: DB::MergeTreeData::alterPartition(std::shared_ptr const&, std::vector> const&, std::shared_ptr) @ 0x0000000016357784 11. /build/src/Interpreters/InterpreterAlterQuery.cpp:242: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x00000000148def37 12. /build/src/Interpreters/InterpreterAlterQuery.cpp:77: DB::InterpreterAlterQuery::execute() @ 0x00000000148dcb0d 13. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88dc9 14. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 15. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 16. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 17. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 18. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 19. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 20. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 21. ? @ 0x00007fbc6213eac3 22. ? @ 0x00007fbc621d0850 2025.07.28 11:52:29.080500 [ 17207 ] {843f77fd-10c6-418e-aec8-086925dc7938} PushingToViews: Failed to push block to view test_5.v1 (4ae2feef-b6fa-47ac-b20c-744da14b2a0a), Stack size too large. Stack address: 0x7fb7fddf0000, frame address: 0x7fb7fe1ef100, stack size: 4198144, maximum stack size: 8388608 2025.07.28 11:52:29.092497 [ 17207 ] {843f77fd-10c6-418e-aec8-086925dc7938} PushingToViews: Failed to push block to view test_5.v2 (7c22a887-3ed3-40f1-a092-d92463e4b87b), Stack size too large. Stack address: 0x7fb7fddf0000, frame address: 0x7fb7fe1ef100, stack size: 4198144, maximum stack size: 8388608 2025.07.28 11:52:29.094703 [ 17207 ] {843f77fd-10c6-418e-aec8-086925dc7938} PushingToViews: Failed to push block to view test_5.v1 (4ae2feef-b6fa-47ac-b20c-744da14b2a0a), Stack size too large. Stack address: 0x7fb7fddf0000, frame address: 0x7fb7fe1ef100, stack size: 4198144, maximum stack size: 8388608 2025.07.28 11:52:29.112741 [ 5879 ] {a98c139e-36f9-4fe4-af65-7ab186aed6e4} executeQuery: Code: 62. DB::Exception: Cannot TRUNCATE dictionary. (SYNTAX_ERROR) (version 25.3.6.10636.altinitytest (altinity build)) (from [::1]:57576) (comment: 02152_dictionary_date32_type.sql) (query 8, line 23) (in query: DROP DICTIONARY test_dictionary;), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000000a074fcb 4. /build/src/Interpreters/InterpreterDropQuery.cpp:266: DB::InterpreterDropQuery::executeToTableImpl(std::shared_ptr const&, DB::ASTDropQuery&, std::shared_ptr&, StrongTypedef, DB::UUIDTag>&) @ 0x0000000014915b7b 5. /build/src/Interpreters/InterpreterDropQuery.cpp:118: DB::InterpreterDropQuery::executeToTable(DB::ASTDropQuery&) @ 0x00000000149137b4 6. /build/src/Interpreters/InterpreterDropQuery.cpp:91: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000014912f07 7. /build/src/Interpreters/InterpreterDropQuery.cpp:72: DB::InterpreterDropQuery::execute() @ 0x0000000014912b65 8. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88dc9 9. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 10. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 11. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 12. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 13. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 14. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 15. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 16. ? @ 0x00007fbc6213eac3 17. ? @ 0x00007fbc621d0850 2025.07.28 11:52:29.114525 [ 17207 ] {843f77fd-10c6-418e-aec8-086925dc7938} PushingToViews: Failed to push block to view test_5.v2 (7c22a887-3ed3-40f1-a092-d92463e4b87b), Stack size too large. Stack address: 0x7fb7fddf0000, frame address: 0x7fb7fe1ef100, stack size: 4198144, maximum stack size: 8388608 2025.07.28 11:52:29.118108 [ 12807 ] {} TCPHandler: Code: 521. DB::ErrnoException: Paths cannot be exchanged because /var/lib/clickhouse/store/d9d/d9d10d50-2ce9-41b4-bbf8-b86fcdd19efe/detached/all_86_86_0 or /var/lib/clickhouse/store/d9d/d9d10d50-2ce9-41b4-bbf8-b86fcdd19efe/detached/attaching_all_86_86_0 does not exist: , errno: 2, strerror: No such file or directory. (ATOMIC_RENAME_FAIL), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:216: DB::ErrnoException::ErrnoException(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String const&) @ 0x0000000013d5fbee 4. /build/src/Common/atomicRename.cpp:97: DB::renameat2(String const&, String const&, int) @ 0x0000000013d5fab0 5. /build/src/Common/atomicRename.cpp:227: DB::renameNoReplace(String const&, String const&) @ 0x0000000013d5f5ba 6. /build/src/Disks/DiskLocal.cpp:318: DB::DiskLocal::moveFile(String const&, String const&) @ 0x0000000013eb1b1e 7. /build/src/Storages/MergeTree/MergeTreeData.cpp:4093: DB::MergeTreeData::PartsTemporaryRename::tryRenameAll() @ 0x000000001633f3c1 8. /build/src/Storages/MergeTree/MergeTreeData.cpp:6783: DB::MergeTreeData::tryLoadPartsToAttach(std::shared_ptr const&, bool, std::shared_ptr, DB::MergeTreeData::PartsTemporaryRename&) @ 0x00000000163646bc 9. /build/src/Storages/StorageReplicatedMergeTree.cpp:6954: DB::StorageReplicatedMergeTree::attachPartition(std::shared_ptr const&, std::shared_ptr const&, bool, std::shared_ptr) @ 0x0000000015f318a4 10. /build/src/Storages/MergeTree/MergeTreeData.cpp:5706: DB::MergeTreeData::alterPartition(std::shared_ptr const&, std::vector> const&, std::shared_ptr) @ 0x0000000016357784 11. /build/src/Interpreters/InterpreterAlterQuery.cpp:242: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x00000000148def37 12. /build/src/Interpreters/InterpreterAlterQuery.cpp:77: DB::InterpreterAlterQuery::execute() @ 0x00000000148dcb0d 13. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88dc9 14. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 15. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 16. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 17. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 18. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 19. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 20. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 21. ? @ 0x00007fbc6213eac3 22. ? @ 0x00007fbc621d0850 2025.07.28 11:52:29.118987 [ 17207 ] {843f77fd-10c6-418e-aec8-086925dc7938} PushingToViews: Failed to push block to view test_5.v1 (4ae2feef-b6fa-47ac-b20c-744da14b2a0a), Stack size too large. Stack address: 0x7fb7fddf0000, frame address: 0x7fb7fe1ef100, stack size: 4198144, maximum stack size: 8388608 2025.07.28 11:52:29.127161 [ 5879 ] {} TCPHandler: Code: 62. DB::Exception: Cannot TRUNCATE dictionary. (SYNTAX_ERROR), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000000a074fcb 4. /build/src/Interpreters/InterpreterDropQuery.cpp:266: DB::InterpreterDropQuery::executeToTableImpl(std::shared_ptr const&, DB::ASTDropQuery&, std::shared_ptr&, StrongTypedef, DB::UUIDTag>&) @ 0x0000000014915b7b 5. /build/src/Interpreters/InterpreterDropQuery.cpp:118: DB::InterpreterDropQuery::executeToTable(DB::ASTDropQuery&) @ 0x00000000149137b4 6. /build/src/Interpreters/InterpreterDropQuery.cpp:91: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000014912f07 7. /build/src/Interpreters/InterpreterDropQuery.cpp:72: DB::InterpreterDropQuery::execute() @ 0x0000000014912b65 8. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88dc9 9. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 10. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 11. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 12. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 13. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 14. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 15. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 16. ? @ 0x00007fbc6213eac3 17. ? @ 0x00007fbc621d0850 2025.07.28 11:52:29.127942 [ 17207 ] {843f77fd-10c6-418e-aec8-086925dc7938} PushingToViews: Failed to push block to view test_5.v2 (7c22a887-3ed3-40f1-a092-d92463e4b87b), Stack size too large. Stack address: 0x7fb7fddf0000, frame address: 0x7fb7fe1ef100, stack size: 4198144, maximum stack size: 8388608 2025.07.28 11:52:29.138429 [ 17207 ] {843f77fd-10c6-418e-aec8-086925dc7938} PushingToViews: Failed to push block to view test_5.v1 (4ae2feef-b6fa-47ac-b20c-744da14b2a0a), Stack size too large. Stack address: 0x7fb7fddf0000, frame address: 0x7fb7fe1ef100, stack size: 4198144, maximum stack size: 8388608 2025.07.28 11:52:29.143570 [ 17207 ] {843f77fd-10c6-418e-aec8-086925dc7938} PushingToViews: Failed to push block to view test_5.v2 (7c22a887-3ed3-40f1-a092-d92463e4b87b), Stack size too large. Stack address: 0x7fb7fddf0000, frame address: 0x7fb7fe1ef100, stack size: 4198144, maximum stack size: 8388608 2025.07.28 11:52:29.165590 [ 17207 ] {843f77fd-10c6-418e-aec8-086925dc7938} PushingToViews: Failed to push block to view test_5.v1 (4ae2feef-b6fa-47ac-b20c-744da14b2a0a), Stack size too large. Stack address: 0x7fb7fddf0000, frame address: 0x7fb7fe1ef100, stack size: 4198144, maximum stack size: 8388608 2025.07.28 11:52:29.167771 [ 17207 ] {843f77fd-10c6-418e-aec8-086925dc7938} PushingToViews: Failed to push block to view test_5.v2 (7c22a887-3ed3-40f1-a092-d92463e4b87b), Stack size too large. Stack address: 0x7fb7fddf0000, frame address: 0x7fb7fe1ef100, stack size: 4198144, maximum stack size: 8388608 2025.07.28 11:52:29.172366 [ 17207 ] {843f77fd-10c6-418e-aec8-086925dc7938} PushingToViews: Failed to push block to view test_5.v1 (4ae2feef-b6fa-47ac-b20c-744da14b2a0a), Stack size too large. Stack address: 0x7fb7fddf0000, frame address: 0x7fb7fe1ef100, stack size: 4198144, maximum stack size: 8388608 2025.07.28 11:52:29.177166 [ 17207 ] {843f77fd-10c6-418e-aec8-086925dc7938} PushingToViews: Failed to push block to view test_5.v2 (7c22a887-3ed3-40f1-a092-d92463e4b87b), Stack size too large. Stack address: 0x7fb7fddf0000, frame address: 0x7fb7fe1ef100, stack size: 4198144, maximum stack size: 8388608 2025.07.28 11:52:29.179207 [ 17207 ] {843f77fd-10c6-418e-aec8-086925dc7938} PushingToViews: Failed to push block to view test_5.v1 (4ae2feef-b6fa-47ac-b20c-744da14b2a0a), Stack size too large. Stack address: 0x7fb7fddf0000, frame address: 0x7fb7fe1ef100, stack size: 4198144, maximum stack size: 8388608 2025.07.28 11:52:29.188625 [ 17207 ] {843f77fd-10c6-418e-aec8-086925dc7938} PushingToViews: Failed to push block to view test_5.v2 (7c22a887-3ed3-40f1-a092-d92463e4b87b), Stack size too large. Stack address: 0x7fb7fddf0000, frame address: 0x7fb7fe1ef100, stack size: 4198144, maximum stack size: 8388608 2025.07.28 11:52:29.192677 [ 17207 ] {843f77fd-10c6-418e-aec8-086925dc7938} PushingToViews: Failed to push block to view test_5.v1 (4ae2feef-b6fa-47ac-b20c-744da14b2a0a), Stack size too large. Stack address: 0x7fb7fddf0000, frame address: 0x7fb7fe1ef100, stack size: 4198144, maximum stack size: 8388608 2025.07.28 11:52:29.196486 [ 17207 ] {843f77fd-10c6-418e-aec8-086925dc7938} PushingToViews: Failed to push block to view test_5.v2 (7c22a887-3ed3-40f1-a092-d92463e4b87b), Stack size too large. Stack address: 0x7fb7fddf0000, frame address: 0x7fb7fe1ef100, stack size: 4198144, maximum stack size: 8388608 2025.07.28 11:52:29.211002 [ 17207 ] {843f77fd-10c6-418e-aec8-086925dc7938} PushingToViews: Failed to push block to view test_5.v1 (4ae2feef-b6fa-47ac-b20c-744da14b2a0a), Stack size too large. Stack address: 0x7fb7fddf0000, frame address: 0x7fb7fe1ef100, stack size: 4198144, maximum stack size: 8388608 2025.07.28 11:52:29.219852 [ 17207 ] {843f77fd-10c6-418e-aec8-086925dc7938} PushingToViews: Failed to push block to view test_5.v2 (7c22a887-3ed3-40f1-a092-d92463e4b87b), Stack size too large. Stack address: 0x7fb7fddf0000, frame address: 0x7fb7fe1ef100, stack size: 4198144, maximum stack size: 8388608 2025.07.28 11:52:29.237320 [ 17207 ] {843f77fd-10c6-418e-aec8-086925dc7938} PushingToViews: Failed to push block to view test_5.v1 (4ae2feef-b6fa-47ac-b20c-744da14b2a0a), Stack size too large. Stack address: 0x7fb7fddf0000, frame address: 0x7fb7fe1ef100, stack size: 4198144, maximum stack size: 8388608 2025.07.28 11:52:29.239503 [ 17207 ] {843f77fd-10c6-418e-aec8-086925dc7938} PushingToViews: Failed to push block to view test_5.v2 (7c22a887-3ed3-40f1-a092-d92463e4b87b), Stack size too large. Stack address: 0x7fb7fddf0000, frame address: 0x7fb7fe1ef100, stack size: 4198144, maximum stack size: 8388608 2025.07.28 11:52:29.241900 [ 17207 ] {843f77fd-10c6-418e-aec8-086925dc7938} PushingToViews: Failed to push block to view test_5.v1 (4ae2feef-b6fa-47ac-b20c-744da14b2a0a), Stack size too large. Stack address: 0x7fb7fddf0000, frame address: 0x7fb7fe1ef100, stack size: 4198144, maximum stack size: 8388608 2025.07.28 11:52:29.244534 [ 17207 ] {843f77fd-10c6-418e-aec8-086925dc7938} PushingToViews: Failed to push block to view test_5.v2 (7c22a887-3ed3-40f1-a092-d92463e4b87b), Stack size too large. Stack address: 0x7fb7fddf0000, frame address: 0x7fb7fe1ef100, stack size: 4198144, maximum stack size: 8388608 2025.07.28 11:52:29.246407 [ 17207 ] {843f77fd-10c6-418e-aec8-086925dc7938} PushingToViews: Failed to push block to view test_5.v1 (4ae2feef-b6fa-47ac-b20c-744da14b2a0a), Stack size too large. Stack address: 0x7fb7fddf0000, frame address: 0x7fb7fe1ef100, stack size: 4198144, maximum stack size: 8388608 2025.07.28 11:52:29.247736 [ 17207 ] {843f77fd-10c6-418e-aec8-086925dc7938} PushingToViews: Failed to push block to view test_5.v2 (7c22a887-3ed3-40f1-a092-d92463e4b87b), Stack size too large. Stack address: 0x7fb7fddf0000, frame address: 0x7fb7fe1ef100, stack size: 4198144, maximum stack size: 8388608 2025.07.28 11:52:29.256832 [ 17207 ] {843f77fd-10c6-418e-aec8-086925dc7938} PushingToViews: Failed to push block to view test_5.v1 (4ae2feef-b6fa-47ac-b20c-744da14b2a0a), Stack size too large. Stack address: 0x7fb7fddf0000, frame address: 0x7fb7fe1ef100, stack size: 4198144, maximum stack size: 8388608 2025.07.28 11:52:29.258463 [ 17207 ] {843f77fd-10c6-418e-aec8-086925dc7938} PushingToViews: Failed to push block to view test_5.v2 (7c22a887-3ed3-40f1-a092-d92463e4b87b), Stack size too large. Stack address: 0x7fb7fddf0000, frame address: 0x7fb7fe1ef100, stack size: 4198144, maximum stack size: 8388608 2025.07.28 11:52:29.265241 [ 17207 ] {843f77fd-10c6-418e-aec8-086925dc7938} PushingToViews: Failed to push block to view test_5.v1 (4ae2feef-b6fa-47ac-b20c-744da14b2a0a), Stack size too large. Stack address: 0x7fb7fddf0000, frame address: 0x7fb7fe1ef100, stack size: 4198144, maximum stack size: 8388608 2025.07.28 11:52:29.270238 [ 17207 ] {843f77fd-10c6-418e-aec8-086925dc7938} PushingToViews: Failed to push block to view test_5.v2 (7c22a887-3ed3-40f1-a092-d92463e4b87b), Stack size too large. Stack address: 0x7fb7fddf0000, frame address: 0x7fb7fe1ef100, stack size: 4198144, maximum stack size: 8388608 2025.07.28 11:52:29.271780 [ 17207 ] {843f77fd-10c6-418e-aec8-086925dc7938} PushingToViews: Failed to push block to view test_5.v1 (4ae2feef-b6fa-47ac-b20c-744da14b2a0a), Stack size too large. Stack address: 0x7fb7fddf0000, frame address: 0x7fb7fe1ef100, stack size: 4198144, maximum stack size: 8388608 2025.07.28 11:52:29.275047 [ 17207 ] {843f77fd-10c6-418e-aec8-086925dc7938} PushingToViews: Failed to push block to view test_5.v2 (7c22a887-3ed3-40f1-a092-d92463e4b87b), Stack size too large. Stack address: 0x7fb7fddf0000, frame address: 0x7fb7fe1ef100, stack size: 4198144, maximum stack size: 8388608 2025.07.28 11:52:29.277572 [ 17207 ] {843f77fd-10c6-418e-aec8-086925dc7938} PushingToViews: Failed to push block to view test_5.v1 (4ae2feef-b6fa-47ac-b20c-744da14b2a0a), Stack size too large. Stack address: 0x7fb7fddf0000, frame address: 0x7fb7fe1ef100, stack size: 4198144, maximum stack size: 8388608 2025.07.28 11:52:29.287626 [ 17207 ] {843f77fd-10c6-418e-aec8-086925dc7938} PushingToViews: Failed to push block to view test_5.v2 (7c22a887-3ed3-40f1-a092-d92463e4b87b), Stack size too large. Stack address: 0x7fb7fddf0000, frame address: 0x7fb7fe1ef100, stack size: 4198144, maximum stack size: 8388608 2025.07.28 11:52:29.301482 [ 17207 ] {843f77fd-10c6-418e-aec8-086925dc7938} PushingToViews: Failed to push block to view test_5.v1 (4ae2feef-b6fa-47ac-b20c-744da14b2a0a), Stack size too large. Stack address: 0x7fb7fddf0000, frame address: 0x7fb7fe1ef100, stack size: 4198144, maximum stack size: 8388608 2025.07.28 11:52:29.303467 [ 17207 ] {843f77fd-10c6-418e-aec8-086925dc7938} PushingToViews: Failed to push block to view test_5.v2 (7c22a887-3ed3-40f1-a092-d92463e4b87b), Stack size too large. Stack address: 0x7fb7fddf0000, frame address: 0x7fb7fe1ef100, stack size: 4198144, maximum stack size: 8388608 2025.07.28 11:52:29.313001 [ 17207 ] {843f77fd-10c6-418e-aec8-086925dc7938} PushingToViews: Failed to push block to view test_5.v1 (4ae2feef-b6fa-47ac-b20c-744da14b2a0a), Stack size too large. Stack address: 0x7fb7fddf0000, frame address: 0x7fb7fe1ef100, stack size: 4198144, maximum stack size: 8388608 2025.07.28 11:52:29.318102 [ 17207 ] {843f77fd-10c6-418e-aec8-086925dc7938} PushingToViews: Failed to push block to view test_5.v2 (7c22a887-3ed3-40f1-a092-d92463e4b87b), Stack size too large. Stack address: 0x7fb7fddf0000, frame address: 0x7fb7fe1ef100, stack size: 4198144, maximum stack size: 8388608 2025.07.28 11:52:29.319340 [ 17207 ] {843f77fd-10c6-418e-aec8-086925dc7938} PushingToViews: Failed to push block to view test_5.v1 (4ae2feef-b6fa-47ac-b20c-744da14b2a0a), Stack size too large. Stack address: 0x7fb7fddf0000, frame address: 0x7fb7fe1ef100, stack size: 4198144, maximum stack size: 8388608 2025.07.28 11:52:29.325996 [ 17207 ] {843f77fd-10c6-418e-aec8-086925dc7938} PushingToViews: Failed to push block to view test_5.v2 (7c22a887-3ed3-40f1-a092-d92463e4b87b), Stack size too large. Stack address: 0x7fb7fddf0000, frame address: 0x7fb7fe1ef100, stack size: 4198144, maximum stack size: 8388608 2025.07.28 11:52:29.328488 [ 17207 ] {843f77fd-10c6-418e-aec8-086925dc7938} PushingToViews: Failed to push block to view test_5.v1 (4ae2feef-b6fa-47ac-b20c-744da14b2a0a), Stack size too large. Stack address: 0x7fb7fddf0000, frame address: 0x7fb7fe1ef100, stack size: 4198144, maximum stack size: 8388608 2025.07.28 11:52:29.332515 [ 17207 ] {843f77fd-10c6-418e-aec8-086925dc7938} PushingToViews: Failed to push block to view test_5.v2 (7c22a887-3ed3-40f1-a092-d92463e4b87b), Stack size too large. Stack address: 0x7fb7fddf0000, frame address: 0x7fb7fe1ef100, stack size: 4198144, maximum stack size: 8388608 2025.07.28 11:52:29.348235 [ 17207 ] {843f77fd-10c6-418e-aec8-086925dc7938} PushingToViews: Failed to push block to view test_5.v1 (4ae2feef-b6fa-47ac-b20c-744da14b2a0a), Stack size too large. Stack address: 0x7fb7fddf0000, frame address: 0x7fb7fe1ef100, stack size: 4198144, maximum stack size: 8388608 2025.07.28 11:52:29.356560 [ 17207 ] {843f77fd-10c6-418e-aec8-086925dc7938} PushingToViews: Failed to push block to view test_5.v2 (7c22a887-3ed3-40f1-a092-d92463e4b87b), Stack size too large. Stack address: 0x7fb7fddf0000, frame address: 0x7fb7fe1ef100, stack size: 4198144, maximum stack size: 8388608 2025.07.28 11:52:29.381941 [ 17207 ] {843f77fd-10c6-418e-aec8-086925dc7938} PushingToViews: Failed to push block to view test_5.v1 (4ae2feef-b6fa-47ac-b20c-744da14b2a0a), Stack size too large. Stack address: 0x7fb7fddf0000, frame address: 0x7fb7fe1ef100, stack size: 4198144, maximum stack size: 8388608 2025.07.28 11:52:29.390756 [ 17207 ] {843f77fd-10c6-418e-aec8-086925dc7938} PushingToViews: Failed to push block to view test_5.v2 (7c22a887-3ed3-40f1-a092-d92463e4b87b), Stack size too large. Stack address: 0x7fb7fddf0000, frame address: 0x7fb7fe1ef100, stack size: 4198144, maximum stack size: 8388608 2025.07.28 11:52:29.391934 [ 17207 ] {843f77fd-10c6-418e-aec8-086925dc7938} PushingToViews: Failed to push block to view test_5.v1 (4ae2feef-b6fa-47ac-b20c-744da14b2a0a), Stack size too large. Stack address: 0x7fb7fddf0000, frame address: 0x7fb7fe1ef100, stack size: 4198144, maximum stack size: 8388608 2025.07.28 11:52:29.394075 [ 17207 ] {843f77fd-10c6-418e-aec8-086925dc7938} PushingToViews: Failed to push block to view test_5.v2 (7c22a887-3ed3-40f1-a092-d92463e4b87b), Stack size too large. Stack address: 0x7fb7fddf0000, frame address: 0x7fb7fe1ef100, stack size: 4198144, maximum stack size: 8388608 2025.07.28 11:52:29.396270 [ 17207 ] {843f77fd-10c6-418e-aec8-086925dc7938} PushingToViews: Failed to push block to view test_5.v1 (4ae2feef-b6fa-47ac-b20c-744da14b2a0a), Stack size too large. Stack address: 0x7fb7fddf0000, frame address: 0x7fb7fe1ef100, stack size: 4198144, maximum stack size: 8388608 2025.07.28 11:52:29.397968 [ 17207 ] {843f77fd-10c6-418e-aec8-086925dc7938} PushingToViews: Failed to push block to view test_5.v2 (7c22a887-3ed3-40f1-a092-d92463e4b87b), Stack size too large. Stack address: 0x7fb7fddf0000, frame address: 0x7fb7fe1ef100, stack size: 4198144, maximum stack size: 8388608 2025.07.28 11:52:29.402035 [ 17207 ] {843f77fd-10c6-418e-aec8-086925dc7938} PushingToViews: Failed to push block to view test_5.v1 (4ae2feef-b6fa-47ac-b20c-744da14b2a0a), Stack size too large. Stack address: 0x7fb7fddf0000, frame address: 0x7fb7fe1ef100, stack size: 4198144, maximum stack size: 8388608 2025.07.28 11:52:29.417324 [ 17207 ] {843f77fd-10c6-418e-aec8-086925dc7938} PushingToViews: Failed to push block to view test_5.v2 (7c22a887-3ed3-40f1-a092-d92463e4b87b), Stack size too large. Stack address: 0x7fb7fddf0000, frame address: 0x7fb7fe1ef100, stack size: 4198144, maximum stack size: 8388608 2025.07.28 11:52:29.420212 [ 17207 ] {843f77fd-10c6-418e-aec8-086925dc7938} PushingToViews: Failed to push block to view test_5.v1 (4ae2feef-b6fa-47ac-b20c-744da14b2a0a), Stack size too large. Stack address: 0x7fb7fddf0000, frame address: 0x7fb7fe1ef100, stack size: 4198144, maximum stack size: 8388608 2025.07.28 11:52:29.422303 [ 17207 ] {843f77fd-10c6-418e-aec8-086925dc7938} PushingToViews: Failed to push block to view test_5.v2 (7c22a887-3ed3-40f1-a092-d92463e4b87b), Stack size too large. Stack address: 0x7fb7fddf0000, frame address: 0x7fb7fe1ef100, stack size: 4198144, maximum stack size: 8388608 2025.07.28 11:52:29.425794 [ 17207 ] {843f77fd-10c6-418e-aec8-086925dc7938} PushingToViews: Failed to push block to view test_5.v1 (4ae2feef-b6fa-47ac-b20c-744da14b2a0a), Stack size too large. Stack address: 0x7fb7fddf0000, frame address: 0x7fb7fe1ef100, stack size: 4198144, maximum stack size: 8388608 2025.07.28 11:52:29.428345 [ 17207 ] {843f77fd-10c6-418e-aec8-086925dc7938} PushingToViews: Failed to push block to view test_5.v2 (7c22a887-3ed3-40f1-a092-d92463e4b87b), Stack size too large. Stack address: 0x7fb7fddf0000, frame address: 0x7fb7fe1ef100, stack size: 4198144, maximum stack size: 8388608 2025.07.28 11:52:29.429076 [ 3964 ] {} test_13.rmt2 (7f9b740d-015c-470e-8cc6-8ba33be0dc63): auto DB::StorageReplicatedMergeTree::processQueueEntry(ReplicatedMergeTreeQueue::SelectedEntryPtr)::(anonymous class)::operator()(LogEntryPtr &) const: Code: 86. DB::HTTPException: Received error from remote server http://146b4357c08d:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Ftest%2F01165%2Ftest_13%2Frmt%2Freplicas%2F1&part=20250728_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.6.10636.altinitytest (altinity build)) '. (RECEIVED_ERROR_FROM_REMOTE_IO_SERVER), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.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 const&, int&&, String const&, unsigned long&&, String const&) @ 0x000000000feda8d9 4. /build/src/IO/HTTPCommon.cpp:104: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x000000000feda6e2 5. /build/src/IO/HTTPCommon.cpp:93: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x000000000feda537 6. /build/src/IO/ReadWriteBufferFromHTTP.cpp:277: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x000000001184a4c4 7. /build/src/IO/ReadWriteBufferFromHTTP.cpp:285: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x000000001184a615 8. /build/src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x000000001184ae59 9. /build/src/IO/ReadWriteBufferFromHTTP.cpp:472: void std::__function::__policy_invoker::__call_impl[abi:se190107]>(std::__function::__policy_storage const*) @ 0x000000001184cedd 10. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001184858b 11. /build/src/IO/ReadWriteBufferFromHTTP.cpp:465: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x000000001184bf0b 12. /build/src/IO/ReadBuffer.h:60: DB::ReadBuffer::next() @ 0x000000000a148c7b 13. /build/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) @ 0x0000000011849fb2 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]>&)>&, 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&) @ 0x0000000011841980 15. /build/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) @ 0x000000001621208e 16. /build/src/Storages/StorageReplicatedMergeTree.cpp:5228: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl[abi:se190107] const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000015f9a5fe 17. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000015ed8bfd 18. /build/src/Storages/StorageReplicatedMergeTree.cpp:2514: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x0000000015ec9aab 19. /build/src/Storages/StorageReplicatedMergeTree.cpp:2349: DB::StorageReplicatedMergeTree::executeLogEntry(DB::ReplicatedMergeTreeLogEntry&) @ 0x0000000015eba91b 20. /build/src/Storages/StorageReplicatedMergeTree.cpp:3876: bool std::__function::__policy_invoker&)>::__call_impl[abi:se190107])::$_1, bool (std::shared_ptr&)>>(std::__function::__policy_storage const*, std::shared_ptr&) @ 0x0000000015f9837e 21. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000165d6fc3 22. /build/src/Storages/StorageReplicatedMergeTree.cpp:3872: DB::StorageReplicatedMergeTree::processQueueEntry(std::shared_ptr) @ 0x0000000015efc18a 23. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001624c1b2 24. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000162f9c70 25. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x00000000162fa55a 26. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc6653 27. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000000fccc4c3 28. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc3d92 29. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fcca080 30. ? @ 0x00007fbc6213eac3 31. ? @ 0x00007fbc621d0850 (version 25.3.6.10636.altinitytest (altinity build)) 2025.07.28 11:52:29.430266 [ 17207 ] {843f77fd-10c6-418e-aec8-086925dc7938} PushingToViews: Failed to push block to view test_5.v1 (4ae2feef-b6fa-47ac-b20c-744da14b2a0a), Stack size too large. Stack address: 0x7fb7fddf0000, frame address: 0x7fb7fe1ef100, stack size: 4198144, maximum stack size: 8388608 2025.07.28 11:52:29.442603 [ 17207 ] {843f77fd-10c6-418e-aec8-086925dc7938} PushingToViews: Failed to push block to view test_5.v2 (7c22a887-3ed3-40f1-a092-d92463e4b87b), Stack size too large. Stack address: 0x7fb7fddf0000, frame address: 0x7fb7fe1ef100, stack size: 4198144, maximum stack size: 8388608 2025.07.28 11:52:29.443854 [ 17207 ] {843f77fd-10c6-418e-aec8-086925dc7938} PushingToViews: Failed to push block to view test_5.v1 (4ae2feef-b6fa-47ac-b20c-744da14b2a0a), Stack size too large. Stack address: 0x7fb7fddf0000, frame address: 0x7fb7fe1ef100, stack size: 4198144, maximum stack size: 8388608 2025.07.28 11:52:29.448370 [ 17207 ] {843f77fd-10c6-418e-aec8-086925dc7938} PushingToViews: Failed to push block to view test_5.v2 (7c22a887-3ed3-40f1-a092-d92463e4b87b), Stack size too large. Stack address: 0x7fb7fddf0000, frame address: 0x7fb7fe1ef100, stack size: 4198144, maximum stack size: 8388608 2025.07.28 11:52:29.449681 [ 17207 ] {843f77fd-10c6-418e-aec8-086925dc7938} PushingToViews: Failed to push block to view test_5.v1 (4ae2feef-b6fa-47ac-b20c-744da14b2a0a), Stack size too large. Stack address: 0x7fb7fddf0000, frame address: 0x7fb7fe1ef100, stack size: 4198144, maximum stack size: 8388608 2025.07.28 11:52:29.452072 [ 17207 ] {843f77fd-10c6-418e-aec8-086925dc7938} PushingToViews: Failed to push block to view test_5.v2 (7c22a887-3ed3-40f1-a092-d92463e4b87b), Stack size too large. Stack address: 0x7fb7fddf0000, frame address: 0x7fb7fe1ef100, stack size: 4198144, maximum stack size: 8388608 2025.07.28 11:52:29.453500 [ 17207 ] {843f77fd-10c6-418e-aec8-086925dc7938} PushingToViews: Failed to push block to view test_5.v1 (4ae2feef-b6fa-47ac-b20c-744da14b2a0a), Stack size too large. Stack address: 0x7fb7fddf0000, frame address: 0x7fb7fe1ef100, stack size: 4198144, maximum stack size: 8388608 2025.07.28 11:52:29.464011 [ 17207 ] {843f77fd-10c6-418e-aec8-086925dc7938} PushingToViews: Failed to push block to view test_5.v2 (7c22a887-3ed3-40f1-a092-d92463e4b87b), Stack size too large. Stack address: 0x7fb7fddf0000, frame address: 0x7fb7fe1ef100, stack size: 4198144, maximum stack size: 8388608 2025.07.28 11:52:29.474603 [ 17207 ] {843f77fd-10c6-418e-aec8-086925dc7938} PushingToViews: Failed to push block to view test_5.v1 (4ae2feef-b6fa-47ac-b20c-744da14b2a0a), Stack size too large. Stack address: 0x7fb7fddf0000, frame address: 0x7fb7fe1ef100, stack size: 4198144, maximum stack size: 8388608 2025.07.28 11:52:29.483502 [ 17207 ] {843f77fd-10c6-418e-aec8-086925dc7938} PushingToViews: Failed to push block to view test_5.v2 (7c22a887-3ed3-40f1-a092-d92463e4b87b), Stack size too large. Stack address: 0x7fb7fddf0000, frame address: 0x7fb7fe1ef100, stack size: 4198144, maximum stack size: 8388608 2025.07.28 11:52:29.485024 [ 17207 ] {843f77fd-10c6-418e-aec8-086925dc7938} PushingToViews: Failed to push block to view test_5.v1 (4ae2feef-b6fa-47ac-b20c-744da14b2a0a), Stack size too large. Stack address: 0x7fb7fddf0000, frame address: 0x7fb7fe1ef100, stack size: 4198144, maximum stack size: 8388608 2025.07.28 11:52:29.486676 [ 17207 ] {843f77fd-10c6-418e-aec8-086925dc7938} PushingToViews: Failed to push block to view test_5.v2 (7c22a887-3ed3-40f1-a092-d92463e4b87b), Stack size too large. Stack address: 0x7fb7fddf0000, frame address: 0x7fb7fe1ef100, stack size: 4198144, maximum stack size: 8388608 2025.07.28 11:52:29.487906 [ 17207 ] {843f77fd-10c6-418e-aec8-086925dc7938} PushingToViews: Failed to push block to view test_5.v1 (4ae2feef-b6fa-47ac-b20c-744da14b2a0a), Stack size too large. Stack address: 0x7fb7fddf0000, frame address: 0x7fb7fe1ef100, stack size: 4198144, maximum stack size: 8388608 2025.07.28 11:52:29.491186 [ 17207 ] {843f77fd-10c6-418e-aec8-086925dc7938} PushingToViews: Failed to push block to view test_5.v2 (7c22a887-3ed3-40f1-a092-d92463e4b87b), Stack size too large. Stack address: 0x7fb7fddf0000, frame address: 0x7fb7fe1ef100, stack size: 4198144, maximum stack size: 8388608 2025.07.28 11:52:29.492269 [ 17207 ] {843f77fd-10c6-418e-aec8-086925dc7938} PushingToViews: Failed to push block to view test_5.v1 (4ae2feef-b6fa-47ac-b20c-744da14b2a0a), Stack size too large. Stack address: 0x7fb7fddf0000, frame address: 0x7fb7fe1ef100, stack size: 4198144, maximum stack size: 8388608 2025.07.28 11:52:29.494222 [ 17207 ] {843f77fd-10c6-418e-aec8-086925dc7938} PushingToViews: Failed to push block to view test_5.v2 (7c22a887-3ed3-40f1-a092-d92463e4b87b), Stack size too large. Stack address: 0x7fb7fddf0000, frame address: 0x7fb7fe1ef100, stack size: 4198144, maximum stack size: 8388608 2025.07.28 11:52:29.496188 [ 17207 ] {843f77fd-10c6-418e-aec8-086925dc7938} PushingToViews: Failed to push block to view test_5.v1 (4ae2feef-b6fa-47ac-b20c-744da14b2a0a), Stack size too large. Stack address: 0x7fb7fddf0000, frame address: 0x7fb7fe1ef100, stack size: 4198144, maximum stack size: 8388608 2025.07.28 11:52:29.497161 [ 17207 ] {843f77fd-10c6-418e-aec8-086925dc7938} PushingToViews: Failed to push block to view test_5.v2 (7c22a887-3ed3-40f1-a092-d92463e4b87b), Stack size too large. Stack address: 0x7fb7fddf0000, frame address: 0x7fb7fe1ef100, stack size: 4198144, maximum stack size: 8388608 2025.07.28 11:52:29.499379 [ 17207 ] {843f77fd-10c6-418e-aec8-086925dc7938} PushingToViews: Failed to push block to view test_5.v1 (4ae2feef-b6fa-47ac-b20c-744da14b2a0a), Stack size too large. Stack address: 0x7fb7fddf0000, frame address: 0x7fb7fe1ef100, stack size: 4198144, maximum stack size: 8388608 2025.07.28 11:52:29.500899 [ 17207 ] {843f77fd-10c6-418e-aec8-086925dc7938} PushingToViews: Failed to push block to view test_5.v2 (7c22a887-3ed3-40f1-a092-d92463e4b87b), Stack size too large. Stack address: 0x7fb7fddf0000, frame address: 0x7fb7fe1ef100, stack size: 4198144, maximum stack size: 8388608 2025.07.28 11:52:29.509952 [ 17207 ] {843f77fd-10c6-418e-aec8-086925dc7938} PushingToViews: Failed to push block to view test_5.v1 (4ae2feef-b6fa-47ac-b20c-744da14b2a0a), Stack size too large. Stack address: 0x7fb7fddf0000, frame address: 0x7fb7fe1ef100, stack size: 4198144, maximum stack size: 8388608 2025.07.28 11:52:29.517067 [ 17207 ] {843f77fd-10c6-418e-aec8-086925dc7938} PushingToViews: Failed to push block to view test_5.v2 (7c22a887-3ed3-40f1-a092-d92463e4b87b), Stack size too large. Stack address: 0x7fb7fddf0000, frame address: 0x7fb7fe1ef100, stack size: 4198144, maximum stack size: 8388608 2025.07.28 11:52:29.535234 [ 17207 ] {843f77fd-10c6-418e-aec8-086925dc7938} PushingToViews: Failed to push block to view test_5.v1 (4ae2feef-b6fa-47ac-b20c-744da14b2a0a), Stack size too large. Stack address: 0x7fb7fddf0000, frame address: 0x7fb7fe1ef100, stack size: 4198144, maximum stack size: 8388608 2025.07.28 11:52:29.536832 [ 17207 ] {843f77fd-10c6-418e-aec8-086925dc7938} PushingToViews: Failed to push block to view test_5.v2 (7c22a887-3ed3-40f1-a092-d92463e4b87b), Stack size too large. Stack address: 0x7fb7fddf0000, frame address: 0x7fb7fe1ef100, stack size: 4198144, maximum stack size: 8388608 2025.07.28 11:52:29.536789 [ 11851 ] {a29d7c47-572b-4411-b480-7b1daf5d6451} executeQuery: Code: 47. DB::Exception: Unknown expression or function identifier `x` in scope x = 1. (UNKNOWN_IDENTIFIER) (version 25.3.6.10636.altinitytest (altinity build)) (from [::1]:57622) (comment: 03272_json_to_json_cast_1.sql) (query 8, line 14) (in query: select json::JSON(max_dynamic_paths=2, max_dynamic_types=1, a UInt32, b String, SKIP c) as json2, JSONDynamicPaths(json2), JSONSharedDataPaths(json2), dynamicType(json2.k2), isDynamicElementInSharedData(json2.k2), dynamicType(json2.k4), isDynamicElementInSharedData(json2.k4) from test;), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.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&&) @ 0x000000001404b3b9 4. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3771: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000001401b849 5. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3980: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000014018e31 6. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:2925: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000001402fcbd 7. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3838: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000014019a9e 8. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:209: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000001401270e 9. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000014011fce 10. /build/src/Planner/Utils.cpp:458: DB::buildFilterInfo(std::shared_ptr, std::shared_ptr const&, std::shared_ptr&, std::unordered_set, std::equal_to, std::allocator>) @ 0x0000000013fe8bcf 11. /build/src/Planner/PlannerJoinTree.cpp:535: DB::(anonymous namespace)::buildQueryPlanForTableExpression(std::shared_ptr, std::shared_ptr const&, DB::SelectQueryInfo const&, DB::SelectQueryOptions const&, std::shared_ptr&, bool, bool) @ 0x00000000149956d3 12. /build/src/Planner/PlannerJoinTree.cpp:2252: DB::buildJoinTreeQueryPlan(std::shared_ptr const&, DB::SelectQueryInfo const&, DB::SelectQueryOptions&, std::unordered_set, std::equal_to, std::allocator> const&, std::shared_ptr&) @ 0x000000001498e109 13. /build/src/Planner/Planner.cpp:1553: DB::Planner::buildPlanForQueryNode() @ 0x0000000014979dae 14. /build/src/Planner/Planner.cpp:1308: DB::Planner::buildQueryPlanIfNeeded() @ 0x000000001497685c 15. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:255: DB::InterpreterSelectQueryAnalyzer::getQueryPlan() @ 0x000000001497476d 16. /build/src/Interpreters/executeQuery.cpp:1405: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88806 17. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 18. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 19. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 20. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 21. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 22. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 23. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 24. ? @ 0x00007fbc6213eac3 25. ? @ 0x00007fbc621d0850 2025.07.28 11:52:29.547239 [ 17207 ] {843f77fd-10c6-418e-aec8-086925dc7938} PushingToViews: Failed to push block to view test_5.v1 (4ae2feef-b6fa-47ac-b20c-744da14b2a0a), Stack size too large. Stack address: 0x7fb7fddf0000, frame address: 0x7fb7fe1ef100, stack size: 4198144, maximum stack size: 8388608 2025.07.28 11:52:29.556849 [ 17207 ] {843f77fd-10c6-418e-aec8-086925dc7938} PushingToViews: Failed to push block to view test_5.v2 (7c22a887-3ed3-40f1-a092-d92463e4b87b), Stack size too large. Stack address: 0x7fb7fddf0000, frame address: 0x7fb7fe1ef100, stack size: 4198144, maximum stack size: 8388608 2025.07.28 11:52:29.560711 [ 17207 ] {843f77fd-10c6-418e-aec8-086925dc7938} PushingToViews: Failed to push block to view test_5.v1 (4ae2feef-b6fa-47ac-b20c-744da14b2a0a), Stack size too large. Stack address: 0x7fb7fddf0000, frame address: 0x7fb7fe1ef100, stack size: 4198144, maximum stack size: 8388608 2025.07.28 11:52:29.566340 [ 11851 ] {} TCPHandler: Code: 47. DB::Exception: Unknown expression or function identifier `x` in scope x = 1. (UNKNOWN_IDENTIFIER), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.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&&) @ 0x000000001404b3b9 4. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3771: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000001401b849 5. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3980: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000014018e31 6. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:2925: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000001402fcbd 7. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3838: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000014019a9e 8. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:209: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000001401270e 9. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000014011fce 10. /build/src/Planner/Utils.cpp:458: DB::buildFilterInfo(std::shared_ptr, std::shared_ptr const&, std::shared_ptr&, std::unordered_set, std::equal_to, std::allocator>) @ 0x0000000013fe8bcf 11. /build/src/Planner/PlannerJoinTree.cpp:535: DB::(anonymous namespace)::buildQueryPlanForTableExpression(std::shared_ptr, std::shared_ptr const&, DB::SelectQueryInfo const&, DB::SelectQueryOptions const&, std::shared_ptr&, bool, bool) @ 0x00000000149956d3 12. /build/src/Planner/PlannerJoinTree.cpp:2252: DB::buildJoinTreeQueryPlan(std::shared_ptr const&, DB::SelectQueryInfo const&, DB::SelectQueryOptions&, std::unordered_set, std::equal_to, std::allocator> const&, std::shared_ptr&) @ 0x000000001498e109 13. /build/src/Planner/Planner.cpp:1553: DB::Planner::buildPlanForQueryNode() @ 0x0000000014979dae 14. /build/src/Planner/Planner.cpp:1308: DB::Planner::buildQueryPlanIfNeeded() @ 0x000000001497685c 15. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:255: DB::InterpreterSelectQueryAnalyzer::getQueryPlan() @ 0x000000001497476d 16. /build/src/Interpreters/executeQuery.cpp:1405: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88806 17. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 18. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 19. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 20. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 21. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 22. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 23. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 24. ? @ 0x00007fbc6213eac3 25. ? @ 0x00007fbc621d0850 2025.07.28 11:52:29.581779 [ 17207 ] {843f77fd-10c6-418e-aec8-086925dc7938} PushingToViews: Failed to push block to view test_5.v2 (7c22a887-3ed3-40f1-a092-d92463e4b87b), Stack size too large. Stack address: 0x7fb7fddf0000, frame address: 0x7fb7fe1ef100, stack size: 4198144, maximum stack size: 8388608 2025.07.28 11:52:29.588376 [ 17207 ] {843f77fd-10c6-418e-aec8-086925dc7938} PushingToViews: Failed to push block to view test_5.v1 (4ae2feef-b6fa-47ac-b20c-744da14b2a0a), Stack size too large. Stack address: 0x7fb7fddf0000, frame address: 0x7fb7fe1ef100, stack size: 4198144, maximum stack size: 8388608 2025.07.28 11:52:29.594433 [ 17207 ] {843f77fd-10c6-418e-aec8-086925dc7938} PushingToViews: Failed to push block to view test_5.v2 (7c22a887-3ed3-40f1-a092-d92463e4b87b), Stack size too large. Stack address: 0x7fb7fddf0000, frame address: 0x7fb7fe1ef100, stack size: 4198144, maximum stack size: 8388608 2025.07.28 11:52:29.597629 [ 17207 ] {843f77fd-10c6-418e-aec8-086925dc7938} PushingToViews: Failed to push block to view test_5.v1 (4ae2feef-b6fa-47ac-b20c-744da14b2a0a), Stack size too large. Stack address: 0x7fb7fddf0000, frame address: 0x7fb7fe1ef100, stack size: 4198144, maximum stack size: 8388608 2025.07.28 11:52:29.603798 [ 17207 ] {843f77fd-10c6-418e-aec8-086925dc7938} PushingToViews: Failed to push block to view test_5.v2 (7c22a887-3ed3-40f1-a092-d92463e4b87b), Stack size too large. Stack address: 0x7fb7fddf0000, frame address: 0x7fb7fe1ef100, stack size: 4198144, maximum stack size: 8388608 2025.07.28 11:52:29.607192 [ 17207 ] {843f77fd-10c6-418e-aec8-086925dc7938} PushingToViews: Failed to push block to view test_5.v1 (4ae2feef-b6fa-47ac-b20c-744da14b2a0a), Stack size too large. Stack address: 0x7fb7fddf0000, frame address: 0x7fb7fe1ef100, stack size: 4198144, maximum stack size: 8388608 2025.07.28 11:52:29.612032 [ 17207 ] {843f77fd-10c6-418e-aec8-086925dc7938} PushingToViews: Failed to push block to view test_5.v2 (7c22a887-3ed3-40f1-a092-d92463e4b87b), Stack size too large. Stack address: 0x7fb7fddf0000, frame address: 0x7fb7fe1ef100, stack size: 4198144, maximum stack size: 8388608 2025.07.28 11:52:29.614941 [ 17207 ] {843f77fd-10c6-418e-aec8-086925dc7938} PushingToViews: Failed to push block to view test_5.v1 (4ae2feef-b6fa-47ac-b20c-744da14b2a0a), Stack size too large. Stack address: 0x7fb7fddf0000, frame address: 0x7fb7fe1ef100, stack size: 4198144, maximum stack size: 8388608 2025.07.28 11:52:29.622182 [ 17207 ] {843f77fd-10c6-418e-aec8-086925dc7938} PushingToViews: Failed to push block to view test_5.v2 (7c22a887-3ed3-40f1-a092-d92463e4b87b), Stack size too large. Stack address: 0x7fb7fddf0000, frame address: 0x7fb7fe1ef100, stack size: 4198144, maximum stack size: 8388608 2025.07.28 11:52:29.633962 [ 17207 ] {843f77fd-10c6-418e-aec8-086925dc7938} PushingToViews: Failed to push block to view test_5.v1 (4ae2feef-b6fa-47ac-b20c-744da14b2a0a), Stack size too large. Stack address: 0x7fb7fddf0000, frame address: 0x7fb7fe1ef100, stack size: 4198144, maximum stack size: 8388608 2025.07.28 11:52:29.641586 [ 17207 ] {843f77fd-10c6-418e-aec8-086925dc7938} PushingToViews: Failed to push block to view test_5.v2 (7c22a887-3ed3-40f1-a092-d92463e4b87b), Stack size too large. Stack address: 0x7fb7fddf0000, frame address: 0x7fb7fe1ef100, stack size: 4198144, maximum stack size: 8388608 2025.07.28 11:52:29.643629 [ 17207 ] {843f77fd-10c6-418e-aec8-086925dc7938} PushingToViews: Failed to push block to view test_5.v1 (4ae2feef-b6fa-47ac-b20c-744da14b2a0a), Stack size too large. Stack address: 0x7fb7fddf0000, frame address: 0x7fb7fe1ef100, stack size: 4198144, maximum stack size: 8388608 2025.07.28 11:52:29.658223 [ 17207 ] {843f77fd-10c6-418e-aec8-086925dc7938} PushingToViews: Failed to push block to view test_5.v2 (7c22a887-3ed3-40f1-a092-d92463e4b87b), Stack size too large. Stack address: 0x7fb7fddf0000, frame address: 0x7fb7fe1ef100, stack size: 4198144, maximum stack size: 8388608 2025.07.28 11:52:29.663758 [ 17207 ] {843f77fd-10c6-418e-aec8-086925dc7938} PushingToViews: Failed to push block to view test_5.v1 (4ae2feef-b6fa-47ac-b20c-744da14b2a0a), Stack size too large. Stack address: 0x7fb7fddf0000, frame address: 0x7fb7fe1ef100, stack size: 4198144, maximum stack size: 8388608 2025.07.28 11:52:29.678166 [ 17207 ] {843f77fd-10c6-418e-aec8-086925dc7938} PushingToViews: Failed to push block to view test_5.v2 (7c22a887-3ed3-40f1-a092-d92463e4b87b), Stack size too large. Stack address: 0x7fb7fddf0000, frame address: 0x7fb7fe1ef100, stack size: 4198144, maximum stack size: 8388608 2025.07.28 11:52:29.679559 [ 17207 ] {843f77fd-10c6-418e-aec8-086925dc7938} PushingToViews: Failed to push block to view test_5.v1 (4ae2feef-b6fa-47ac-b20c-744da14b2a0a), Stack size too large. Stack address: 0x7fb7fddf0000, frame address: 0x7fb7fe1ef100, stack size: 4198144, maximum stack size: 8388608 2025.07.28 11:52:29.681527 [ 17207 ] {843f77fd-10c6-418e-aec8-086925dc7938} PushingToViews: Failed to push block to view test_5.v2 (7c22a887-3ed3-40f1-a092-d92463e4b87b), Stack size too large. Stack address: 0x7fb7fddf0000, frame address: 0x7fb7fe1ef100, stack size: 4198144, maximum stack size: 8388608 2025.07.28 11:52:29.696304 [ 17207 ] {843f77fd-10c6-418e-aec8-086925dc7938} PushingToViews: Failed to push block to view test_5.v1 (4ae2feef-b6fa-47ac-b20c-744da14b2a0a), Stack size too large. Stack address: 0x7fb7fddf0000, frame address: 0x7fb7fe1ef100, stack size: 4198144, maximum stack size: 8388608 2025.07.28 11:52:29.701777 [ 17207 ] {843f77fd-10c6-418e-aec8-086925dc7938} PushingToViews: Failed to push block to view test_5.v2 (7c22a887-3ed3-40f1-a092-d92463e4b87b), Stack size too large. Stack address: 0x7fb7fddf0000, frame address: 0x7fb7fe1ef100, stack size: 4198144, maximum stack size: 8388608 2025.07.28 11:52:29.703380 [ 17207 ] {843f77fd-10c6-418e-aec8-086925dc7938} PushingToViews: Failed to push block to view test_5.v1 (4ae2feef-b6fa-47ac-b20c-744da14b2a0a), Stack size too large. Stack address: 0x7fb7fddf0000, frame address: 0x7fb7fe1ef100, stack size: 4198144, maximum stack size: 8388608 2025.07.28 11:52:29.708207 [ 17207 ] {843f77fd-10c6-418e-aec8-086925dc7938} PushingToViews: Failed to push block to view test_5.v2 (7c22a887-3ed3-40f1-a092-d92463e4b87b), Stack size too large. Stack address: 0x7fb7fddf0000, frame address: 0x7fb7fe1ef100, stack size: 4198144, maximum stack size: 8388608 2025.07.28 11:52:29.709874 [ 17207 ] {843f77fd-10c6-418e-aec8-086925dc7938} PushingToViews: Failed to push block to view test_5.v1 (4ae2feef-b6fa-47ac-b20c-744da14b2a0a), Stack size too large. Stack address: 0x7fb7fddf0000, frame address: 0x7fb7fe1ef100, stack size: 4198144, maximum stack size: 8388608 2025.07.28 11:52:29.719440 [ 17207 ] {843f77fd-10c6-418e-aec8-086925dc7938} PushingToViews: Failed to push block to view test_5.v2 (7c22a887-3ed3-40f1-a092-d92463e4b87b), Stack size too large. Stack address: 0x7fb7fddf0000, frame address: 0x7fb7fe1ef100, stack size: 4198144, maximum stack size: 8388608 2025.07.28 11:52:29.721834 [ 17207 ] {843f77fd-10c6-418e-aec8-086925dc7938} PushingToViews: Failed to push block to view test_5.v1 (4ae2feef-b6fa-47ac-b20c-744da14b2a0a), Stack size too large. Stack address: 0x7fb7fddf0000, frame address: 0x7fb7fe1ef100, stack size: 4198144, maximum stack size: 8388608 2025.07.28 11:52:29.725577 [ 17207 ] {843f77fd-10c6-418e-aec8-086925dc7938} PushingToViews: Failed to push block to view test_5.v2 (7c22a887-3ed3-40f1-a092-d92463e4b87b), Stack size too large. Stack address: 0x7fb7fddf0000, frame address: 0x7fb7fe1ef100, stack size: 4198144, maximum stack size: 8388608 2025.07.28 11:52:29.727532 [ 17207 ] {843f77fd-10c6-418e-aec8-086925dc7938} PushingToViews: Failed to push block to view test_5.v1 (4ae2feef-b6fa-47ac-b20c-744da14b2a0a), Stack size too large. Stack address: 0x7fb7fddf0000, frame address: 0x7fb7fe1ef100, stack size: 4198144, maximum stack size: 8388608 2025.07.28 11:52:29.809360 [ 17207 ] {843f77fd-10c6-418e-aec8-086925dc7938} PushingToViews: Failed to push block to view test_5.v2 (7c22a887-3ed3-40f1-a092-d92463e4b87b), Stack size too large. Stack address: 0x7fb7fddf0000, frame address: 0x7fb7fe1ef100, stack size: 4198144, maximum stack size: 8388608 2025.07.28 11:52:29.812047 [ 17207 ] {843f77fd-10c6-418e-aec8-086925dc7938} PushingToViews: Failed to push block to view test_5.v1 (4ae2feef-b6fa-47ac-b20c-744da14b2a0a), Stack size too large. Stack address: 0x7fb7fddf0000, frame address: 0x7fb7fe1ef100, stack size: 4198144, maximum stack size: 8388608 2025.07.28 11:52:29.813408 [ 17207 ] {843f77fd-10c6-418e-aec8-086925dc7938} PushingToViews: Failed to push block to view test_5.v2 (7c22a887-3ed3-40f1-a092-d92463e4b87b), Stack size too large. Stack address: 0x7fb7fddf0000, frame address: 0x7fb7fe1ef100, stack size: 4198144, maximum stack size: 8388608 2025.07.28 11:52:29.814829 [ 17207 ] {843f77fd-10c6-418e-aec8-086925dc7938} PushingToViews: Failed to push block to view test_5.v1 (4ae2feef-b6fa-47ac-b20c-744da14b2a0a), Stack size too large. Stack address: 0x7fb7fddf0000, frame address: 0x7fb7fe1ef100, stack size: 4198144, maximum stack size: 8388608 2025.07.28 11:52:29.817430 [ 17207 ] {843f77fd-10c6-418e-aec8-086925dc7938} PushingToViews: Failed to push block to view test_5.v2 (7c22a887-3ed3-40f1-a092-d92463e4b87b), Stack size too large. Stack address: 0x7fb7fddf0000, frame address: 0x7fb7fe1ef100, stack size: 4198144, maximum stack size: 8388608 2025.07.28 11:52:29.819228 [ 17207 ] {843f77fd-10c6-418e-aec8-086925dc7938} PushingToViews: Failed to push block to view test_5.v1 (4ae2feef-b6fa-47ac-b20c-744da14b2a0a), Stack size too large. Stack address: 0x7fb7fddf0000, frame address: 0x7fb7fe1ef100, stack size: 4198144, maximum stack size: 8388608 2025.07.28 11:52:29.821212 [ 17207 ] {843f77fd-10c6-418e-aec8-086925dc7938} PushingToViews: Failed to push block to view test_5.v2 (7c22a887-3ed3-40f1-a092-d92463e4b87b), Stack size too large. Stack address: 0x7fb7fddf0000, frame address: 0x7fb7fe1ef100, stack size: 4198144, maximum stack size: 8388608 2025.07.28 11:52:29.823049 [ 17207 ] {843f77fd-10c6-418e-aec8-086925dc7938} PushingToViews: Failed to push block to view test_5.v1 (4ae2feef-b6fa-47ac-b20c-744da14b2a0a), Stack size too large. Stack address: 0x7fb7fddf0000, frame address: 0x7fb7fe1ef100, stack size: 4198144, maximum stack size: 8388608 2025.07.28 11:52:29.825092 [ 17207 ] {843f77fd-10c6-418e-aec8-086925dc7938} PushingToViews: Failed to push block to view test_5.v2 (7c22a887-3ed3-40f1-a092-d92463e4b87b), Stack size too large. Stack address: 0x7fb7fddf0000, frame address: 0x7fb7fe1ef100, stack size: 4198144, maximum stack size: 8388608 2025.07.28 11:52:29.826331 [ 17207 ] {843f77fd-10c6-418e-aec8-086925dc7938} PushingToViews: Failed to push block to view test_5.v1 (4ae2feef-b6fa-47ac-b20c-744da14b2a0a), Stack size too large. Stack address: 0x7fb7fddf0000, frame address: 0x7fb7fe1ef100, stack size: 4198144, maximum stack size: 8388608 2025.07.28 11:52:29.827850 [ 17207 ] {843f77fd-10c6-418e-aec8-086925dc7938} PushingToViews: Failed to push block to view test_5.v2 (7c22a887-3ed3-40f1-a092-d92463e4b87b), Stack size too large. Stack address: 0x7fb7fddf0000, frame address: 0x7fb7fe1ef100, stack size: 4198144, maximum stack size: 8388608 2025.07.28 11:52:29.830329 [ 17207 ] {843f77fd-10c6-418e-aec8-086925dc7938} PushingToViews: Failed to push block to view test_5.v1 (4ae2feef-b6fa-47ac-b20c-744da14b2a0a), Stack size too large. Stack address: 0x7fb7fddf0000, frame address: 0x7fb7fe1ef100, stack size: 4198144, maximum stack size: 8388608 2025.07.28 11:52:29.832950 [ 17207 ] {843f77fd-10c6-418e-aec8-086925dc7938} PushingToViews: Failed to push block to view test_5.v2 (7c22a887-3ed3-40f1-a092-d92463e4b87b), Stack size too large. Stack address: 0x7fb7fddf0000, frame address: 0x7fb7fe1ef100, stack size: 4198144, maximum stack size: 8388608 2025.07.28 11:52:29.840062 [ 17207 ] {843f77fd-10c6-418e-aec8-086925dc7938} PushingToViews: Failed to push block to view test_5.v1 (4ae2feef-b6fa-47ac-b20c-744da14b2a0a), Stack size too large. Stack address: 0x7fb7fddf0000, frame address: 0x7fb7fe1ef100, stack size: 4198144, maximum stack size: 8388608 2025.07.28 11:52:29.842434 [ 17207 ] {843f77fd-10c6-418e-aec8-086925dc7938} PushingToViews: Failed to push block to view test_5.v2 (7c22a887-3ed3-40f1-a092-d92463e4b87b), Stack size too large. Stack address: 0x7fb7fddf0000, frame address: 0x7fb7fe1ef100, stack size: 4198144, maximum stack size: 8388608 2025.07.28 11:52:29.844467 [ 17207 ] {843f77fd-10c6-418e-aec8-086925dc7938} PushingToViews: Failed to push block to view test_5.v1 (4ae2feef-b6fa-47ac-b20c-744da14b2a0a), Stack size too large. Stack address: 0x7fb7fddf0000, frame address: 0x7fb7fe1ef100, stack size: 4198144, maximum stack size: 8388608 2025.07.28 11:52:29.846290 [ 17207 ] {843f77fd-10c6-418e-aec8-086925dc7938} PushingToViews: Failed to push block to view test_5.v2 (7c22a887-3ed3-40f1-a092-d92463e4b87b), Stack size too large. Stack address: 0x7fb7fddf0000, frame address: 0x7fb7fe1ef100, stack size: 4198144, maximum stack size: 8388608 2025.07.28 11:52:29.848012 [ 17207 ] {843f77fd-10c6-418e-aec8-086925dc7938} PushingToViews: Failed to push block to view test_5.v1 (4ae2feef-b6fa-47ac-b20c-744da14b2a0a), Stack size too large. Stack address: 0x7fb7fddf0000, frame address: 0x7fb7fe1ef100, stack size: 4198144, maximum stack size: 8388608 2025.07.28 11:52:29.853491 [ 17207 ] {843f77fd-10c6-418e-aec8-086925dc7938} PushingToViews: Failed to push block to view test_5.v2 (7c22a887-3ed3-40f1-a092-d92463e4b87b), Stack size too large. Stack address: 0x7fb7fddf0000, frame address: 0x7fb7fe1ef100, stack size: 4198144, maximum stack size: 8388608 2025.07.28 11:52:29.855477 [ 17207 ] {843f77fd-10c6-418e-aec8-086925dc7938} PushingToViews: Failed to push block to view test_5.v1 (4ae2feef-b6fa-47ac-b20c-744da14b2a0a), Stack size too large. Stack address: 0x7fb7fddf0000, frame address: 0x7fb7fe1ef100, stack size: 4198144, maximum stack size: 8388608 2025.07.28 11:52:29.864739 [ 17207 ] {843f77fd-10c6-418e-aec8-086925dc7938} PushingToViews: Failed to push block to view test_5.v2 (7c22a887-3ed3-40f1-a092-d92463e4b87b), Stack size too large. Stack address: 0x7fb7fddf0000, frame address: 0x7fb7fe1ef100, stack size: 4198144, maximum stack size: 8388608 2025.07.28 11:52:29.865869 [ 17207 ] {843f77fd-10c6-418e-aec8-086925dc7938} PushingToViews: Failed to push block to view test_5.v1 (4ae2feef-b6fa-47ac-b20c-744da14b2a0a), Stack size too large. Stack address: 0x7fb7fddf0000, frame address: 0x7fb7fe1ef100, stack size: 4198144, maximum stack size: 8388608 2025.07.28 11:52:29.866765 [ 17207 ] {843f77fd-10c6-418e-aec8-086925dc7938} PushingToViews: Failed to push block to view test_5.v2 (7c22a887-3ed3-40f1-a092-d92463e4b87b), Stack size too large. Stack address: 0x7fb7fddf0000, frame address: 0x7fb7fe1ef100, stack size: 4198144, maximum stack size: 8388608 2025.07.28 11:52:29.868132 [ 17207 ] {843f77fd-10c6-418e-aec8-086925dc7938} PushingToViews: Failed to push block to view test_5.v1 (4ae2feef-b6fa-47ac-b20c-744da14b2a0a), Stack size too large. Stack address: 0x7fb7fddf0000, frame address: 0x7fb7fe1ef100, stack size: 4198144, maximum stack size: 8388608 2025.07.28 11:52:29.879906 [ 17207 ] {843f77fd-10c6-418e-aec8-086925dc7938} PushingToViews: Failed to push block to view test_5.v2 (7c22a887-3ed3-40f1-a092-d92463e4b87b), Stack size too large. Stack address: 0x7fb7fddf0000, frame address: 0x7fb7fe1ef100, stack size: 4198144, maximum stack size: 8388608 2025.07.28 11:52:29.889017 [ 17207 ] {843f77fd-10c6-418e-aec8-086925dc7938} PushingToViews: Failed to push block to view test_5.v1 (4ae2feef-b6fa-47ac-b20c-744da14b2a0a), Stack size too large. Stack address: 0x7fb7fddf0000, frame address: 0x7fb7fe1ef100, stack size: 4198144, maximum stack size: 8388608 2025.07.28 11:52:29.890294 [ 17207 ] {843f77fd-10c6-418e-aec8-086925dc7938} PushingToViews: Failed to push block to view test_5.v2 (7c22a887-3ed3-40f1-a092-d92463e4b87b), Stack size too large. Stack address: 0x7fb7fddf0000, frame address: 0x7fb7fe1ef100, stack size: 4198144, maximum stack size: 8388608 2025.07.28 11:52:29.896204 [ 17207 ] {843f77fd-10c6-418e-aec8-086925dc7938} PushingToViews: Failed to push block to view test_5.v1 (4ae2feef-b6fa-47ac-b20c-744da14b2a0a), Stack size too large. Stack address: 0x7fb7fddf0000, frame address: 0x7fb7fe1ef100, stack size: 4198144, maximum stack size: 8388608 2025.07.28 11:52:29.897659 [ 17207 ] {843f77fd-10c6-418e-aec8-086925dc7938} PushingToViews: Failed to push block to view test_5.v2 (7c22a887-3ed3-40f1-a092-d92463e4b87b), Stack size too large. Stack address: 0x7fb7fddf0000, frame address: 0x7fb7fe1ef100, stack size: 4198144, maximum stack size: 8388608 2025.07.28 11:52:29.899752 [ 17207 ] {843f77fd-10c6-418e-aec8-086925dc7938} PushingToViews: Failed to push block to view test_5.v1 (4ae2feef-b6fa-47ac-b20c-744da14b2a0a), Stack size too large. Stack address: 0x7fb7fddf0000, frame address: 0x7fb7fe1ef100, stack size: 4198144, maximum stack size: 8388608 2025.07.28 11:52:29.913585 [ 17207 ] {843f77fd-10c6-418e-aec8-086925dc7938} PushingToViews: Failed to push block to view test_5.v2 (7c22a887-3ed3-40f1-a092-d92463e4b87b), Stack size too large. Stack address: 0x7fb7fddf0000, frame address: 0x7fb7fe1ef100, stack size: 4198144, maximum stack size: 8388608 2025.07.28 11:52:29.918321 [ 17207 ] {843f77fd-10c6-418e-aec8-086925dc7938} PushingToViews: Failed to push block to view test_5.v1 (4ae2feef-b6fa-47ac-b20c-744da14b2a0a), Stack size too large. Stack address: 0x7fb7fddf0000, frame address: 0x7fb7fe1ef100, stack size: 4198144, maximum stack size: 8388608 2025.07.28 11:52:29.919458 [ 17207 ] {843f77fd-10c6-418e-aec8-086925dc7938} PushingToViews: Failed to push block to view test_5.v2 (7c22a887-3ed3-40f1-a092-d92463e4b87b), Stack size too large. Stack address: 0x7fb7fddf0000, frame address: 0x7fb7fe1ef100, stack size: 4198144, maximum stack size: 8388608 2025.07.28 11:52:29.920457 [ 17207 ] {843f77fd-10c6-418e-aec8-086925dc7938} PushingToViews: Failed to push block to view test_5.v1 (4ae2feef-b6fa-47ac-b20c-744da14b2a0a), Stack size too large. Stack address: 0x7fb7fddf0000, frame address: 0x7fb7fe1ef100, stack size: 4198144, maximum stack size: 8388608 2025.07.28 11:52:29.924474 [ 17207 ] {843f77fd-10c6-418e-aec8-086925dc7938} PushingToViews: Failed to push block to view test_5.v2 (7c22a887-3ed3-40f1-a092-d92463e4b87b), Stack size too large. Stack address: 0x7fb7fddf0000, frame address: 0x7fb7fe1ef100, stack size: 4198144, maximum stack size: 8388608 2025.07.28 11:52:29.926922 [ 17207 ] {843f77fd-10c6-418e-aec8-086925dc7938} PushingToViews: Failed to push block to view test_5.v1 (4ae2feef-b6fa-47ac-b20c-744da14b2a0a), Stack size too large. Stack address: 0x7fb7fddf0000, frame address: 0x7fb7fe1ef100, stack size: 4198144, maximum stack size: 8388608 2025.07.28 11:52:29.928997 [ 17207 ] {843f77fd-10c6-418e-aec8-086925dc7938} PushingToViews: Failed to push block to view test_5.v2 (7c22a887-3ed3-40f1-a092-d92463e4b87b), Stack size too large. Stack address: 0x7fb7fddf0000, frame address: 0x7fb7fe1ef100, stack size: 4198144, maximum stack size: 8388608 2025.07.28 11:52:29.930409 [ 17207 ] {843f77fd-10c6-418e-aec8-086925dc7938} PushingToViews: Failed to push block to view test_5.v1 (4ae2feef-b6fa-47ac-b20c-744da14b2a0a), Stack size too large. Stack address: 0x7fb7fddf0000, frame address: 0x7fb7fe1ef100, stack size: 4198144, maximum stack size: 8388608 2025.07.28 11:52:29.931326 [ 17207 ] {843f77fd-10c6-418e-aec8-086925dc7938} PushingToViews: Failed to push block to view test_5.v2 (7c22a887-3ed3-40f1-a092-d92463e4b87b), Stack size too large. Stack address: 0x7fb7fddf0000, frame address: 0x7fb7fe1ef100, stack size: 4198144, maximum stack size: 8388608 2025.07.28 11:52:29.932562 [ 17207 ] {843f77fd-10c6-418e-aec8-086925dc7938} PushingToViews: Failed to push block to view test_5.v1 (4ae2feef-b6fa-47ac-b20c-744da14b2a0a), Stack size too large. Stack address: 0x7fb7fddf0000, frame address: 0x7fb7fe1ef100, stack size: 4198144, maximum stack size: 8388608 2025.07.28 11:52:29.934636 [ 17207 ] {843f77fd-10c6-418e-aec8-086925dc7938} PushingToViews: Failed to push block to view test_5.v2 (7c22a887-3ed3-40f1-a092-d92463e4b87b), Stack size too large. Stack address: 0x7fb7fddf0000, frame address: 0x7fb7fe1ef100, stack size: 4198144, maximum stack size: 8388608 2025.07.28 11:52:29.935854 [ 17207 ] {843f77fd-10c6-418e-aec8-086925dc7938} PushingToViews: Failed to push block to view test_5.v1 (4ae2feef-b6fa-47ac-b20c-744da14b2a0a), Stack size too large. Stack address: 0x7fb7fddf0000, frame address: 0x7fb7fe1ef100, stack size: 4198144, maximum stack size: 8388608 2025.07.28 11:52:29.937407 [ 17207 ] {843f77fd-10c6-418e-aec8-086925dc7938} PushingToViews: Failed to push block to view test_5.v2 (7c22a887-3ed3-40f1-a092-d92463e4b87b), Stack size too large. Stack address: 0x7fb7fddf0000, frame address: 0x7fb7fe1ef100, stack size: 4198144, maximum stack size: 8388608 2025.07.28 11:52:29.939525 [ 17207 ] {843f77fd-10c6-418e-aec8-086925dc7938} PushingToViews: Failed to push block to view test_5.v1 (4ae2feef-b6fa-47ac-b20c-744da14b2a0a), Stack size too large. Stack address: 0x7fb7fddf0000, frame address: 0x7fb7fe1ef100, stack size: 4198144, maximum stack size: 8388608 2025.07.28 11:52:29.941857 [ 17207 ] {843f77fd-10c6-418e-aec8-086925dc7938} PushingToViews: Failed to push block to view test_5.v2 (7c22a887-3ed3-40f1-a092-d92463e4b87b), Stack size too large. Stack address: 0x7fb7fddf0000, frame address: 0x7fb7fe1ef100, stack size: 4198144, maximum stack size: 8388608 2025.07.28 11:52:29.943628 [ 17207 ] {843f77fd-10c6-418e-aec8-086925dc7938} PushingToViews: Failed to push block to view test_5.v1 (4ae2feef-b6fa-47ac-b20c-744da14b2a0a), Stack size too large. Stack address: 0x7fb7fddf0000, frame address: 0x7fb7fe1ef100, stack size: 4198144, maximum stack size: 8388608 2025.07.28 11:52:29.965333 [ 17207 ] {843f77fd-10c6-418e-aec8-086925dc7938} PushingToViews: Failed to push block to view test_5.v2 (7c22a887-3ed3-40f1-a092-d92463e4b87b), Stack size too large. Stack address: 0x7fb7fddf0000, frame address: 0x7fb7fe1ef100, stack size: 4198144, maximum stack size: 8388608 2025.07.28 11:52:29.967882 [ 17207 ] {843f77fd-10c6-418e-aec8-086925dc7938} PushingToViews: Failed to push block to view test_5.v1 (4ae2feef-b6fa-47ac-b20c-744da14b2a0a), Stack size too large. Stack address: 0x7fb7fddf0000, frame address: 0x7fb7fe1ef100, stack size: 4198144, maximum stack size: 8388608 2025.07.28 11:52:29.974191 [ 17207 ] {843f77fd-10c6-418e-aec8-086925dc7938} PushingToViews: Failed to push block to view test_5.v2 (7c22a887-3ed3-40f1-a092-d92463e4b87b), Stack size too large. Stack address: 0x7fb7fddf0000, frame address: 0x7fb7fe1ef100, stack size: 4198144, maximum stack size: 8388608 2025.07.28 11:52:29.977305 [ 17207 ] {843f77fd-10c6-418e-aec8-086925dc7938} PushingToViews: Failed to push block to view test_5.v1 (4ae2feef-b6fa-47ac-b20c-744da14b2a0a), Stack size too large. Stack address: 0x7fb7fddf0000, frame address: 0x7fb7fe1ef100, stack size: 4198144, maximum stack size: 8388608 2025.07.28 11:52:29.995890 [ 17207 ] {843f77fd-10c6-418e-aec8-086925dc7938} PushingToViews: Failed to push block to view test_5.v2 (7c22a887-3ed3-40f1-a092-d92463e4b87b), Stack size too large. Stack address: 0x7fb7fddf0000, frame address: 0x7fb7fe1ef100, stack size: 4198144, maximum stack size: 8388608 2025.07.28 11:52:29.997088 [ 17207 ] {843f77fd-10c6-418e-aec8-086925dc7938} PushingToViews: Failed to push block to view test_5.v1 (4ae2feef-b6fa-47ac-b20c-744da14b2a0a), Stack size too large. Stack address: 0x7fb7fddf0000, frame address: 0x7fb7fe1ef100, stack size: 4198144, maximum stack size: 8388608 2025.07.28 11:52:29.998664 [ 17207 ] {843f77fd-10c6-418e-aec8-086925dc7938} PushingToViews: Failed to push block to view test_5.v2 (7c22a887-3ed3-40f1-a092-d92463e4b87b), Stack size too large. Stack address: 0x7fb7fddf0000, frame address: 0x7fb7fe1ef100, stack size: 4198144, maximum stack size: 8388608 2025.07.28 11:52:30.020422 [ 17207 ] {843f77fd-10c6-418e-aec8-086925dc7938} PushingToViews: Failed to push block to view test_5.v1 (4ae2feef-b6fa-47ac-b20c-744da14b2a0a), Stack size too large. Stack address: 0x7fb7fddf0000, frame address: 0x7fb7fe1ef100, stack size: 4198144, maximum stack size: 8388608 2025.07.28 11:52:30.025565 [ 17207 ] {843f77fd-10c6-418e-aec8-086925dc7938} PushingToViews: Failed to push block to view test_5.v2 (7c22a887-3ed3-40f1-a092-d92463e4b87b), Stack size too large. Stack address: 0x7fb7fddf0000, frame address: 0x7fb7fe1ef100, stack size: 4198144, maximum stack size: 8388608 2025.07.28 11:52:30.027299 [ 17207 ] {843f77fd-10c6-418e-aec8-086925dc7938} PushingToViews: Failed to push block to view test_5.v1 (4ae2feef-b6fa-47ac-b20c-744da14b2a0a), Stack size too large. Stack address: 0x7fb7fddf0000, frame address: 0x7fb7fe1ef100, stack size: 4198144, maximum stack size: 8388608 2025.07.28 11:52:30.040137 [ 17207 ] {843f77fd-10c6-418e-aec8-086925dc7938} PushingToViews: Failed to push block to view test_5.v2 (7c22a887-3ed3-40f1-a092-d92463e4b87b), Stack size too large. Stack address: 0x7fb7fddf0000, frame address: 0x7fb7fe1ef100, stack size: 4198144, maximum stack size: 8388608 2025.07.28 11:52:30.061138 [ 17207 ] {843f77fd-10c6-418e-aec8-086925dc7938} PushingToViews: Failed to push block to view test_5.v1 (4ae2feef-b6fa-47ac-b20c-744da14b2a0a), Stack size too large. Stack address: 0x7fb7fddf0000, frame address: 0x7fb7fe1ef100, stack size: 4198144, maximum stack size: 8388608 2025.07.28 11:52:30.074808 [ 17207 ] {843f77fd-10c6-418e-aec8-086925dc7938} PushingToViews: Failed to push block to view test_5.v2 (7c22a887-3ed3-40f1-a092-d92463e4b87b), Stack size too large. Stack address: 0x7fb7fddf0000, frame address: 0x7fb7fe1ef100, stack size: 4198144, maximum stack size: 8388608 2025.07.28 11:52:30.081234 [ 17207 ] {843f77fd-10c6-418e-aec8-086925dc7938} PushingToViews: Failed to push block to view test_5.v1 (4ae2feef-b6fa-47ac-b20c-744da14b2a0a), Stack size too large. Stack address: 0x7fb7fddf0000, frame address: 0x7fb7fe1ef100, stack size: 4198144, maximum stack size: 8388608 2025.07.28 11:52:30.094026 [ 17207 ] {843f77fd-10c6-418e-aec8-086925dc7938} PushingToViews: Failed to push block to view test_5.v2 (7c22a887-3ed3-40f1-a092-d92463e4b87b), Stack size too large. Stack address: 0x7fb7fddf0000, frame address: 0x7fb7fe1ef100, stack size: 4198144, maximum stack size: 8388608 2025.07.28 11:52:30.099780 [ 17207 ] {843f77fd-10c6-418e-aec8-086925dc7938} PushingToViews: Failed to push block to view test_5.v1 (4ae2feef-b6fa-47ac-b20c-744da14b2a0a), Stack size too large. Stack address: 0x7fb7fddf0000, frame address: 0x7fb7fe1ef100, stack size: 4198144, maximum stack size: 8388608 2025.07.28 11:52:30.147912 [ 17207 ] {843f77fd-10c6-418e-aec8-086925dc7938} PushingToViews: Failed to push block to view test_5.v2 (7c22a887-3ed3-40f1-a092-d92463e4b87b), Stack size too large. Stack address: 0x7fb7fddf0000, frame address: 0x7fb7fe1ef100, stack size: 4198144, maximum stack size: 8388608 2025.07.28 11:52:30.152900 [ 17207 ] {843f77fd-10c6-418e-aec8-086925dc7938} PushingToViews: Failed to push block to view test_5.v1 (4ae2feef-b6fa-47ac-b20c-744da14b2a0a), Stack size too large. Stack address: 0x7fb7fddf0000, frame address: 0x7fb7fe1ef100, stack size: 4198144, maximum stack size: 8388608 2025.07.28 11:52:30.159825 [ 17207 ] {843f77fd-10c6-418e-aec8-086925dc7938} PushingToViews: Failed to push block to view test_5.v2 (7c22a887-3ed3-40f1-a092-d92463e4b87b), Stack size too large. Stack address: 0x7fb7fddf0000, frame address: 0x7fb7fe1ef100, stack size: 4198144, maximum stack size: 8388608 2025.07.28 11:52:30.162137 [ 17207 ] {843f77fd-10c6-418e-aec8-086925dc7938} PushingToViews: Failed to push block to view test_5.v1 (4ae2feef-b6fa-47ac-b20c-744da14b2a0a), Stack size too large. Stack address: 0x7fb7fddf0000, frame address: 0x7fb7fe1ef100, stack size: 4198144, maximum stack size: 8388608 2025.07.28 11:52:30.165735 [ 17207 ] {843f77fd-10c6-418e-aec8-086925dc7938} PushingToViews: Failed to push block to view test_5.v2 (7c22a887-3ed3-40f1-a092-d92463e4b87b), Stack size too large. Stack address: 0x7fb7fddf0000, frame address: 0x7fb7fe1ef100, stack size: 4198144, maximum stack size: 8388608 2025.07.28 11:52:30.167243 [ 17207 ] {843f77fd-10c6-418e-aec8-086925dc7938} PushingToViews: Failed to push block to view test_5.v1 (4ae2feef-b6fa-47ac-b20c-744da14b2a0a), Stack size too large. Stack address: 0x7fb7fddf0000, frame address: 0x7fb7fe1ef100, stack size: 4198144, maximum stack size: 8388608 2025.07.28 11:52:30.177122 [ 17207 ] {843f77fd-10c6-418e-aec8-086925dc7938} PushingToViews: Failed to push block to view test_5.v2 (7c22a887-3ed3-40f1-a092-d92463e4b87b), Stack size too large. Stack address: 0x7fb7fddf0000, frame address: 0x7fb7fe1ef100, stack size: 4198144, maximum stack size: 8388608 2025.07.28 11:52:30.183710 [ 17207 ] {843f77fd-10c6-418e-aec8-086925dc7938} PushingToViews: Failed to push block to view test_5.v1 (4ae2feef-b6fa-47ac-b20c-744da14b2a0a), Stack size too large. Stack address: 0x7fb7fddf0000, frame address: 0x7fb7fe1ef100, stack size: 4198144, maximum stack size: 8388608 2025.07.28 11:52:30.197062 [ 17207 ] {843f77fd-10c6-418e-aec8-086925dc7938} PushingToViews: Failed to push block to view test_5.v2 (7c22a887-3ed3-40f1-a092-d92463e4b87b), Stack size too large. Stack address: 0x7fb7fddf0000, frame address: 0x7fb7fe1ef100, stack size: 4198144, maximum stack size: 8388608 2025.07.28 11:52:30.200379 [ 17207 ] {843f77fd-10c6-418e-aec8-086925dc7938} PushingToViews: Failed to push block to view test_5.v1 (4ae2feef-b6fa-47ac-b20c-744da14b2a0a), Stack size too large. Stack address: 0x7fb7fddf0000, frame address: 0x7fb7fe1ef100, stack size: 4198144, maximum stack size: 8388608 2025.07.28 11:52:30.208225 [ 17207 ] {843f77fd-10c6-418e-aec8-086925dc7938} PushingToViews: Failed to push block to view test_5.v2 (7c22a887-3ed3-40f1-a092-d92463e4b87b), Stack size too large. Stack address: 0x7fb7fddf0000, frame address: 0x7fb7fe1ef100, stack size: 4198144, maximum stack size: 8388608 2025.07.28 11:52:30.209592 [ 17207 ] {843f77fd-10c6-418e-aec8-086925dc7938} PushingToViews: Failed to push block to view test_5.v1 (4ae2feef-b6fa-47ac-b20c-744da14b2a0a), Stack size too large. Stack address: 0x7fb7fddf0000, frame address: 0x7fb7fe1ef100, stack size: 4198144, maximum stack size: 8388608 2025.07.28 11:52:30.211129 [ 17207 ] {843f77fd-10c6-418e-aec8-086925dc7938} PushingToViews: Failed to push block to view test_5.v2 (7c22a887-3ed3-40f1-a092-d92463e4b87b), Stack size too large. Stack address: 0x7fb7fddf0000, frame address: 0x7fb7fe1ef100, stack size: 4198144, maximum stack size: 8388608 2025.07.28 11:52:30.218168 [ 17207 ] {843f77fd-10c6-418e-aec8-086925dc7938} PushingToViews: Failed to push block to view test_5.v1 (4ae2feef-b6fa-47ac-b20c-744da14b2a0a), Stack size too large. Stack address: 0x7fb7fddf0000, frame address: 0x7fb7fe1ef100, stack size: 4198144, maximum stack size: 8388608 2025.07.28 11:52:30.221270 [ 17207 ] {843f77fd-10c6-418e-aec8-086925dc7938} PushingToViews: Failed to push block to view test_5.v2 (7c22a887-3ed3-40f1-a092-d92463e4b87b), Stack size too large. Stack address: 0x7fb7fddf0000, frame address: 0x7fb7fe1ef100, stack size: 4198144, maximum stack size: 8388608 2025.07.28 11:52:30.223121 [ 17207 ] {843f77fd-10c6-418e-aec8-086925dc7938} PushingToViews: Failed to push block to view test_5.v1 (4ae2feef-b6fa-47ac-b20c-744da14b2a0a), Stack size too large. Stack address: 0x7fb7fddf0000, frame address: 0x7fb7fe1ef100, stack size: 4198144, maximum stack size: 8388608 2025.07.28 11:52:30.224669 [ 17207 ] {843f77fd-10c6-418e-aec8-086925dc7938} PushingToViews: Failed to push block to view test_5.v2 (7c22a887-3ed3-40f1-a092-d92463e4b87b), Stack size too large. Stack address: 0x7fb7fddf0000, frame address: 0x7fb7fe1ef100, stack size: 4198144, maximum stack size: 8388608 2025.07.28 11:52:30.227667 [ 17207 ] {843f77fd-10c6-418e-aec8-086925dc7938} PushingToViews: Failed to push block to view test_5.v1 (4ae2feef-b6fa-47ac-b20c-744da14b2a0a), Stack size too large. Stack address: 0x7fb7fddf0000, frame address: 0x7fb7fe1ef100, stack size: 4198144, maximum stack size: 8388608 2025.07.28 11:52:30.229246 [ 17207 ] {843f77fd-10c6-418e-aec8-086925dc7938} PushingToViews: Failed to push block to view test_5.v2 (7c22a887-3ed3-40f1-a092-d92463e4b87b), Stack size too large. Stack address: 0x7fb7fddf0000, frame address: 0x7fb7fe1ef100, stack size: 4198144, maximum stack size: 8388608 2025.07.28 11:52:30.231149 [ 17207 ] {843f77fd-10c6-418e-aec8-086925dc7938} PushingToViews: Failed to push block to view test_5.v1 (4ae2feef-b6fa-47ac-b20c-744da14b2a0a), Stack size too large. Stack address: 0x7fb7fddf0000, frame address: 0x7fb7fe1ef100, stack size: 4198144, maximum stack size: 8388608 2025.07.28 11:52:30.236649 [ 17207 ] {843f77fd-10c6-418e-aec8-086925dc7938} PushingToViews: Failed to push block to view test_5.v2 (7c22a887-3ed3-40f1-a092-d92463e4b87b), Stack size too large. Stack address: 0x7fb7fddf0000, frame address: 0x7fb7fe1ef100, stack size: 4198144, maximum stack size: 8388608 2025.07.28 11:52:30.238527 [ 17207 ] {843f77fd-10c6-418e-aec8-086925dc7938} PushingToViews: Failed to push block to view test_5.v1 (4ae2feef-b6fa-47ac-b20c-744da14b2a0a), Stack size too large. Stack address: 0x7fb7fddf0000, frame address: 0x7fb7fe1ef100, stack size: 4198144, maximum stack size: 8388608 2025.07.28 11:52:30.243391 [ 17207 ] {843f77fd-10c6-418e-aec8-086925dc7938} PushingToViews: Failed to push block to view test_5.v2 (7c22a887-3ed3-40f1-a092-d92463e4b87b), Stack size too large. Stack address: 0x7fb7fddf0000, frame address: 0x7fb7fe1ef100, stack size: 4198144, maximum stack size: 8388608 2025.07.28 11:52:30.246320 [ 17207 ] {843f77fd-10c6-418e-aec8-086925dc7938} PushingToViews: Failed to push block to view test_5.v1 (4ae2feef-b6fa-47ac-b20c-744da14b2a0a), Stack size too large. Stack address: 0x7fb7fddf0000, frame address: 0x7fb7fe1ef100, stack size: 4198144, maximum stack size: 8388608 2025.07.28 11:52:30.260519 [ 17207 ] {843f77fd-10c6-418e-aec8-086925dc7938} PushingToViews: Failed to push block to view test_5.v2 (7c22a887-3ed3-40f1-a092-d92463e4b87b), Stack size too large. Stack address: 0x7fb7fddf0000, frame address: 0x7fb7fe1ef100, stack size: 4198144, maximum stack size: 8388608 2025.07.28 11:52:30.264623 [ 17207 ] {843f77fd-10c6-418e-aec8-086925dc7938} PushingToViews: Failed to push block to view test_5.v1 (4ae2feef-b6fa-47ac-b20c-744da14b2a0a), Stack size too large. Stack address: 0x7fb7fddf0000, frame address: 0x7fb7fe1ef100, stack size: 4198144, maximum stack size: 8388608 2025.07.28 11:52:30.266800 [ 17207 ] {843f77fd-10c6-418e-aec8-086925dc7938} PushingToViews: Failed to push block to view test_5.v2 (7c22a887-3ed3-40f1-a092-d92463e4b87b), Stack size too large. Stack address: 0x7fb7fddf0000, frame address: 0x7fb7fe1ef100, stack size: 4198144, maximum stack size: 8388608 2025.07.28 11:52:30.273071 [ 17207 ] {843f77fd-10c6-418e-aec8-086925dc7938} PushingToViews: Failed to push block to view test_5.v1 (4ae2feef-b6fa-47ac-b20c-744da14b2a0a), Stack size too large. Stack address: 0x7fb7fddf0000, frame address: 0x7fb7fe1ef100, stack size: 4198144, maximum stack size: 8388608 2025.07.28 11:52:30.276198 [ 17207 ] {843f77fd-10c6-418e-aec8-086925dc7938} PushingToViews: Failed to push block to view test_5.v2 (7c22a887-3ed3-40f1-a092-d92463e4b87b), Stack size too large. Stack address: 0x7fb7fddf0000, frame address: 0x7fb7fe1ef100, stack size: 4198144, maximum stack size: 8388608 2025.07.28 11:52:30.281106 [ 17207 ] {843f77fd-10c6-418e-aec8-086925dc7938} PushingToViews: Failed to push block to view test_5.v1 (4ae2feef-b6fa-47ac-b20c-744da14b2a0a), Stack size too large. Stack address: 0x7fb7fddf0000, frame address: 0x7fb7fe1ef100, stack size: 4198144, maximum stack size: 8388608 2025.07.28 11:52:30.284357 [ 17207 ] {843f77fd-10c6-418e-aec8-086925dc7938} PushingToViews: Failed to push block to view test_5.v2 (7c22a887-3ed3-40f1-a092-d92463e4b87b), Stack size too large. Stack address: 0x7fb7fddf0000, frame address: 0x7fb7fe1ef100, stack size: 4198144, maximum stack size: 8388608 2025.07.28 11:52:30.287514 [ 17207 ] {843f77fd-10c6-418e-aec8-086925dc7938} PushingToViews: Failed to push block to view test_5.v1 (4ae2feef-b6fa-47ac-b20c-744da14b2a0a), Stack size too large. Stack address: 0x7fb7fddf0000, frame address: 0x7fb7fe1ef100, stack size: 4198144, maximum stack size: 8388608 2025.07.28 11:52:30.289871 [ 17207 ] {843f77fd-10c6-418e-aec8-086925dc7938} PushingToViews: Failed to push block to view test_5.v2 (7c22a887-3ed3-40f1-a092-d92463e4b87b), Stack size too large. Stack address: 0x7fb7fddf0000, frame address: 0x7fb7fe1ef100, stack size: 4198144, maximum stack size: 8388608 2025.07.28 11:52:30.294201 [ 17207 ] {843f77fd-10c6-418e-aec8-086925dc7938} PushingToViews: Failed to push block to view test_5.v1 (4ae2feef-b6fa-47ac-b20c-744da14b2a0a), Stack size too large. Stack address: 0x7fb7fddf0000, frame address: 0x7fb7fe1ef100, stack size: 4198144, maximum stack size: 8388608 2025.07.28 11:52:30.300168 [ 17207 ] {843f77fd-10c6-418e-aec8-086925dc7938} PushingToViews: Failed to push block to view test_5.v2 (7c22a887-3ed3-40f1-a092-d92463e4b87b), Stack size too large. Stack address: 0x7fb7fddf0000, frame address: 0x7fb7fe1ef100, stack size: 4198144, maximum stack size: 8388608 2025.07.28 11:52:30.312956 [ 17207 ] {843f77fd-10c6-418e-aec8-086925dc7938} PushingToViews: Failed to push block to view test_5.v1 (4ae2feef-b6fa-47ac-b20c-744da14b2a0a), Stack size too large. Stack address: 0x7fb7fddf0000, frame address: 0x7fb7fe1ef100, stack size: 4198144, maximum stack size: 8388608 2025.07.28 11:52:30.320480 [ 17207 ] {843f77fd-10c6-418e-aec8-086925dc7938} PushingToViews: Failed to push block to view test_5.v2 (7c22a887-3ed3-40f1-a092-d92463e4b87b), Stack size too large. Stack address: 0x7fb7fddf0000, frame address: 0x7fb7fe1ef100, stack size: 4198144, maximum stack size: 8388608 2025.07.28 11:52:30.332927 [ 17207 ] {843f77fd-10c6-418e-aec8-086925dc7938} PushingToViews: Failed to push block to view test_5.v1 (4ae2feef-b6fa-47ac-b20c-744da14b2a0a), Stack size too large. Stack address: 0x7fb7fddf0000, frame address: 0x7fb7fe1ef100, stack size: 4198144, maximum stack size: 8388608 2025.07.28 11:52:30.341520 [ 17207 ] {843f77fd-10c6-418e-aec8-086925dc7938} PushingToViews: Failed to push block to view test_5.v2 (7c22a887-3ed3-40f1-a092-d92463e4b87b), Stack size too large. Stack address: 0x7fb7fddf0000, frame address: 0x7fb7fe1ef100, stack size: 4198144, maximum stack size: 8388608 2025.07.28 11:52:30.343439 [ 17207 ] {843f77fd-10c6-418e-aec8-086925dc7938} PushingToViews: Failed to push block to view test_5.v1 (4ae2feef-b6fa-47ac-b20c-744da14b2a0a), Stack size too large. Stack address: 0x7fb7fddf0000, frame address: 0x7fb7fe1ef100, stack size: 4198144, maximum stack size: 8388608 2025.07.28 11:52:30.349732 [ 17207 ] {843f77fd-10c6-418e-aec8-086925dc7938} PushingToViews: Failed to push block to view test_5.v2 (7c22a887-3ed3-40f1-a092-d92463e4b87b), Stack size too large. Stack address: 0x7fb7fddf0000, frame address: 0x7fb7fe1ef100, stack size: 4198144, maximum stack size: 8388608 2025.07.28 11:52:30.351823 [ 17207 ] {843f77fd-10c6-418e-aec8-086925dc7938} PushingToViews: Failed to push block to view test_5.v1 (4ae2feef-b6fa-47ac-b20c-744da14b2a0a), Stack size too large. Stack address: 0x7fb7fddf0000, frame address: 0x7fb7fe1ef100, stack size: 4198144, maximum stack size: 8388608 2025.07.28 11:52:30.354152 [ 17207 ] {843f77fd-10c6-418e-aec8-086925dc7938} PushingToViews: Failed to push block to view test_5.v2 (7c22a887-3ed3-40f1-a092-d92463e4b87b), Stack size too large. Stack address: 0x7fb7fddf0000, frame address: 0x7fb7fe1ef100, stack size: 4198144, maximum stack size: 8388608 2025.07.28 11:52:30.357837 [ 17207 ] {843f77fd-10c6-418e-aec8-086925dc7938} PushingToViews: Failed to push block to view test_5.v1 (4ae2feef-b6fa-47ac-b20c-744da14b2a0a), Stack size too large. Stack address: 0x7fb7fddf0000, frame address: 0x7fb7fe1ef100, stack size: 4198144, maximum stack size: 8388608 2025.07.28 11:52:30.360631 [ 17207 ] {843f77fd-10c6-418e-aec8-086925dc7938} PushingToViews: Failed to push block to view test_5.v2 (7c22a887-3ed3-40f1-a092-d92463e4b87b), Stack size too large. Stack address: 0x7fb7fddf0000, frame address: 0x7fb7fe1ef100, stack size: 4198144, maximum stack size: 8388608 2025.07.28 11:52:30.370101 [ 17207 ] {843f77fd-10c6-418e-aec8-086925dc7938} PushingToViews: Failed to push block to view test_5.v1 (4ae2feef-b6fa-47ac-b20c-744da14b2a0a), Stack size too large. Stack address: 0x7fb7fddf0000, frame address: 0x7fb7fe1ef100, stack size: 4198144, maximum stack size: 8388608 2025.07.28 11:52:30.442315 [ 17207 ] {843f77fd-10c6-418e-aec8-086925dc7938} PushingToViews: Failed to push block to view test_5.v2 (7c22a887-3ed3-40f1-a092-d92463e4b87b), Stack size too large. Stack address: 0x7fb7fddf0000, frame address: 0x7fb7fe1ef100, stack size: 4198144, maximum stack size: 8388608 2025.07.28 11:52:30.445394 [ 17207 ] {843f77fd-10c6-418e-aec8-086925dc7938} PushingToViews: Failed to push block to view test_5.v1 (4ae2feef-b6fa-47ac-b20c-744da14b2a0a), Stack size too large. Stack address: 0x7fb7fddf0000, frame address: 0x7fb7fe1ef100, stack size: 4198144, maximum stack size: 8388608 2025.07.28 11:52:30.447727 [ 17207 ] {843f77fd-10c6-418e-aec8-086925dc7938} PushingToViews: Failed to push block to view test_5.v2 (7c22a887-3ed3-40f1-a092-d92463e4b87b), Stack size too large. Stack address: 0x7fb7fddf0000, frame address: 0x7fb7fe1ef100, stack size: 4198144, maximum stack size: 8388608 2025.07.28 11:52:30.448858 [ 17207 ] {843f77fd-10c6-418e-aec8-086925dc7938} PushingToViews: Failed to push block to view test_5.v1 (4ae2feef-b6fa-47ac-b20c-744da14b2a0a), Stack size too large. Stack address: 0x7fb7fddf0000, frame address: 0x7fb7fe1ef100, stack size: 4198144, maximum stack size: 8388608 2025.07.28 11:52:30.450195 [ 17207 ] {843f77fd-10c6-418e-aec8-086925dc7938} PushingToViews: Failed to push block to view test_5.v2 (7c22a887-3ed3-40f1-a092-d92463e4b87b), Stack size too large. Stack address: 0x7fb7fddf0000, frame address: 0x7fb7fe1ef100, stack size: 4198144, maximum stack size: 8388608 2025.07.28 11:52:30.451894 [ 17207 ] {843f77fd-10c6-418e-aec8-086925dc7938} PushingToViews: Failed to push block to view test_5.v1 (4ae2feef-b6fa-47ac-b20c-744da14b2a0a), Stack size too large. Stack address: 0x7fb7fddf0000, frame address: 0x7fb7fe1ef100, stack size: 4198144, maximum stack size: 8388608 2025.07.28 11:52:30.460661 [ 17207 ] {843f77fd-10c6-418e-aec8-086925dc7938} PushingToViews: Failed to push block to view test_5.v2 (7c22a887-3ed3-40f1-a092-d92463e4b87b), Stack size too large. Stack address: 0x7fb7fddf0000, frame address: 0x7fb7fe1ef100, stack size: 4198144, maximum stack size: 8388608 2025.07.28 11:52:30.462208 [ 17207 ] {843f77fd-10c6-418e-aec8-086925dc7938} PushingToViews: Failed to push block to view test_5.v1 (4ae2feef-b6fa-47ac-b20c-744da14b2a0a), Stack size too large. Stack address: 0x7fb7fddf0000, frame address: 0x7fb7fe1ef100, stack size: 4198144, maximum stack size: 8388608 2025.07.28 11:52:30.463030 [ 17207 ] {843f77fd-10c6-418e-aec8-086925dc7938} PushingToViews: Failed to push block to view test_5.v2 (7c22a887-3ed3-40f1-a092-d92463e4b87b), Stack size too large. Stack address: 0x7fb7fddf0000, frame address: 0x7fb7fe1ef100, stack size: 4198144, maximum stack size: 8388608 2025.07.28 11:52:30.463822 [ 17207 ] {843f77fd-10c6-418e-aec8-086925dc7938} PushingToViews: Failed to push block to view test_5.v1 (4ae2feef-b6fa-47ac-b20c-744da14b2a0a), Stack size too large. Stack address: 0x7fb7fddf0000, frame address: 0x7fb7fe1ef100, stack size: 4198144, maximum stack size: 8388608 2025.07.28 11:52:30.465390 [ 17207 ] {843f77fd-10c6-418e-aec8-086925dc7938} PushingToViews: Failed to push block to view test_5.v2 (7c22a887-3ed3-40f1-a092-d92463e4b87b), Stack size too large. Stack address: 0x7fb7fddf0000, frame address: 0x7fb7fe1ef100, stack size: 4198144, maximum stack size: 8388608 2025.07.28 11:52:30.471484 [ 17207 ] {843f77fd-10c6-418e-aec8-086925dc7938} PushingToViews: Failed to push block to view test_5.v1 (4ae2feef-b6fa-47ac-b20c-744da14b2a0a), Stack size too large. Stack address: 0x7fb7fddf0000, frame address: 0x7fb7fe1ef100, stack size: 4198144, maximum stack size: 8388608 2025.07.28 11:52:30.472503 [ 17207 ] {843f77fd-10c6-418e-aec8-086925dc7938} PushingToViews: Failed to push block to view test_5.v2 (7c22a887-3ed3-40f1-a092-d92463e4b87b), Stack size too large. Stack address: 0x7fb7fddf0000, frame address: 0x7fb7fe1ef100, stack size: 4198144, maximum stack size: 8388608 2025.07.28 11:52:30.474053 [ 17207 ] {843f77fd-10c6-418e-aec8-086925dc7938} PushingToViews: Failed to push block to view test_5.v1 (4ae2feef-b6fa-47ac-b20c-744da14b2a0a), Stack size too large. Stack address: 0x7fb7fddf0000, frame address: 0x7fb7fe1ef100, stack size: 4198144, maximum stack size: 8388608 2025.07.28 11:52:30.475675 [ 17207 ] {843f77fd-10c6-418e-aec8-086925dc7938} PushingToViews: Failed to push block to view test_5.v2 (7c22a887-3ed3-40f1-a092-d92463e4b87b), Stack size too large. Stack address: 0x7fb7fddf0000, frame address: 0x7fb7fe1ef100, stack size: 4198144, maximum stack size: 8388608 2025.07.28 11:52:30.476895 [ 17207 ] {843f77fd-10c6-418e-aec8-086925dc7938} PushingToViews: Failed to push block to view test_5.v1 (4ae2feef-b6fa-47ac-b20c-744da14b2a0a), Stack size too large. Stack address: 0x7fb7fddf0000, frame address: 0x7fb7fe1ef100, stack size: 4198144, maximum stack size: 8388608 2025.07.28 11:52:30.478056 [ 17207 ] {843f77fd-10c6-418e-aec8-086925dc7938} PushingToViews: Failed to push block to view test_5.v2 (7c22a887-3ed3-40f1-a092-d92463e4b87b), Stack size too large. Stack address: 0x7fb7fddf0000, frame address: 0x7fb7fe1ef100, stack size: 4198144, maximum stack size: 8388608 2025.07.28 11:52:30.488046 [ 17207 ] {843f77fd-10c6-418e-aec8-086925dc7938} PushingToViews: Failed to push block to view test_5.v1 (4ae2feef-b6fa-47ac-b20c-744da14b2a0a), Stack size too large. Stack address: 0x7fb7fddf0000, frame address: 0x7fb7fe1ef100, stack size: 4198144, maximum stack size: 8388608 2025.07.28 11:52:30.502263 [ 17207 ] {843f77fd-10c6-418e-aec8-086925dc7938} PushingToViews: Failed to push block to view test_5.v2 (7c22a887-3ed3-40f1-a092-d92463e4b87b), Stack size too large. Stack address: 0x7fb7fddf0000, frame address: 0x7fb7fe1ef100, stack size: 4198144, maximum stack size: 8388608 2025.07.28 11:52:30.504018 [ 17207 ] {843f77fd-10c6-418e-aec8-086925dc7938} PushingToViews: Failed to push block to view test_5.v1 (4ae2feef-b6fa-47ac-b20c-744da14b2a0a), Stack size too large. Stack address: 0x7fb7fddf0000, frame address: 0x7fb7fe1ef100, stack size: 4198144, maximum stack size: 8388608 2025.07.28 11:52:30.505733 [ 17207 ] {843f77fd-10c6-418e-aec8-086925dc7938} PushingToViews: Failed to push block to view test_5.v2 (7c22a887-3ed3-40f1-a092-d92463e4b87b), Stack size too large. Stack address: 0x7fb7fddf0000, frame address: 0x7fb7fe1ef100, stack size: 4198144, maximum stack size: 8388608 2025.07.28 11:52:30.506944 [ 17207 ] {843f77fd-10c6-418e-aec8-086925dc7938} PushingToViews: Failed to push block to view test_5.v1 (4ae2feef-b6fa-47ac-b20c-744da14b2a0a), Stack size too large. Stack address: 0x7fb7fddf0000, frame address: 0x7fb7fe1ef100, stack size: 4198144, maximum stack size: 8388608 2025.07.28 11:52:30.508201 [ 17207 ] {843f77fd-10c6-418e-aec8-086925dc7938} PushingToViews: Failed to push block to view test_5.v2 (7c22a887-3ed3-40f1-a092-d92463e4b87b), Stack size too large. Stack address: 0x7fb7fddf0000, frame address: 0x7fb7fe1ef100, stack size: 4198144, maximum stack size: 8388608 2025.07.28 11:52:30.510289 [ 17207 ] {843f77fd-10c6-418e-aec8-086925dc7938} PushingToViews: Failed to push block to view test_5.v1 (4ae2feef-b6fa-47ac-b20c-744da14b2a0a), Stack size too large. Stack address: 0x7fb7fddf0000, frame address: 0x7fb7fe1ef100, stack size: 4198144, maximum stack size: 8388608 2025.07.28 11:52:30.511566 [ 17207 ] {843f77fd-10c6-418e-aec8-086925dc7938} PushingToViews: Failed to push block to view test_5.v2 (7c22a887-3ed3-40f1-a092-d92463e4b87b), Stack size too large. Stack address: 0x7fb7fddf0000, frame address: 0x7fb7fe1ef100, stack size: 4198144, maximum stack size: 8388608 2025.07.28 11:52:30.512711 [ 17207 ] {843f77fd-10c6-418e-aec8-086925dc7938} PushingToViews: Failed to push block to view test_5.v1 (4ae2feef-b6fa-47ac-b20c-744da14b2a0a), Stack size too large. Stack address: 0x7fb7fddf0000, frame address: 0x7fb7fe1ef100, stack size: 4198144, maximum stack size: 8388608 2025.07.28 11:52:30.516157 [ 17207 ] {843f77fd-10c6-418e-aec8-086925dc7938} PushingToViews: Failed to push block to view test_5.v2 (7c22a887-3ed3-40f1-a092-d92463e4b87b), Stack size too large. Stack address: 0x7fb7fddf0000, frame address: 0x7fb7fe1ef100, stack size: 4198144, maximum stack size: 8388608 2025.07.28 11:52:30.518829 [ 17207 ] {843f77fd-10c6-418e-aec8-086925dc7938} PushingToViews: Failed to push block to view test_5.v1 (4ae2feef-b6fa-47ac-b20c-744da14b2a0a), Stack size too large. Stack address: 0x7fb7fddf0000, frame address: 0x7fb7fe1ef100, stack size: 4198144, maximum stack size: 8388608 2025.07.28 11:52:30.520765 [ 17207 ] {843f77fd-10c6-418e-aec8-086925dc7938} PushingToViews: Failed to push block to view test_5.v2 (7c22a887-3ed3-40f1-a092-d92463e4b87b), Stack size too large. Stack address: 0x7fb7fddf0000, frame address: 0x7fb7fe1ef100, stack size: 4198144, maximum stack size: 8388608 2025.07.28 11:52:30.524037 [ 17207 ] {843f77fd-10c6-418e-aec8-086925dc7938} PushingToViews: Failed to push block to view test_5.v1 (4ae2feef-b6fa-47ac-b20c-744da14b2a0a), Stack size too large. Stack address: 0x7fb7fddf0000, frame address: 0x7fb7fe1ef100, stack size: 4198144, maximum stack size: 8388608 2025.07.28 11:52:30.527193 [ 17207 ] {843f77fd-10c6-418e-aec8-086925dc7938} PushingToViews: Failed to push block to view test_5.v2 (7c22a887-3ed3-40f1-a092-d92463e4b87b), Stack size too large. Stack address: 0x7fb7fddf0000, frame address: 0x7fb7fe1ef100, stack size: 4198144, maximum stack size: 8388608 2025.07.28 11:52:30.529004 [ 17207 ] {843f77fd-10c6-418e-aec8-086925dc7938} PushingToViews: Failed to push block to view test_5.v1 (4ae2feef-b6fa-47ac-b20c-744da14b2a0a), Stack size too large. Stack address: 0x7fb7fddf0000, frame address: 0x7fb7fe1ef100, stack size: 4198144, maximum stack size: 8388608 2025.07.28 11:52:30.530365 [ 17207 ] {843f77fd-10c6-418e-aec8-086925dc7938} PushingToViews: Failed to push block to view test_5.v2 (7c22a887-3ed3-40f1-a092-d92463e4b87b), Stack size too large. Stack address: 0x7fb7fddf0000, frame address: 0x7fb7fe1ef100, stack size: 4198144, maximum stack size: 8388608 2025.07.28 11:52:30.538510 [ 17207 ] {843f77fd-10c6-418e-aec8-086925dc7938} PushingToViews: Failed to push block to view test_5.v1 (4ae2feef-b6fa-47ac-b20c-744da14b2a0a), Stack size too large. Stack address: 0x7fb7fddf0000, frame address: 0x7fb7fe1ef100, stack size: 4198144, maximum stack size: 8388608 2025.07.28 11:52:30.543219 [ 17207 ] {843f77fd-10c6-418e-aec8-086925dc7938} PushingToViews: Failed to push block to view test_5.v2 (7c22a887-3ed3-40f1-a092-d92463e4b87b), Stack size too large. Stack address: 0x7fb7fddf0000, frame address: 0x7fb7fe1ef100, stack size: 4198144, maximum stack size: 8388608 2025.07.28 11:52:30.545950 [ 17207 ] {843f77fd-10c6-418e-aec8-086925dc7938} PushingToViews: Failed to push block to view test_5.v1 (4ae2feef-b6fa-47ac-b20c-744da14b2a0a), Stack size too large. Stack address: 0x7fb7fddf0000, frame address: 0x7fb7fe1ef100, stack size: 4198144, maximum stack size: 8388608 2025.07.28 11:52:30.547541 [ 17207 ] {843f77fd-10c6-418e-aec8-086925dc7938} PushingToViews: Failed to push block to view test_5.v2 (7c22a887-3ed3-40f1-a092-d92463e4b87b), Stack size too large. Stack address: 0x7fb7fddf0000, frame address: 0x7fb7fe1ef100, stack size: 4198144, maximum stack size: 8388608 2025.07.28 11:52:30.551045 [ 17207 ] {843f77fd-10c6-418e-aec8-086925dc7938} PushingToViews: Failed to push block to view test_5.v1 (4ae2feef-b6fa-47ac-b20c-744da14b2a0a), Stack size too large. Stack address: 0x7fb7fddf0000, frame address: 0x7fb7fe1ef100, stack size: 4198144, maximum stack size: 8388608 2025.07.28 11:52:30.560383 [ 17207 ] {843f77fd-10c6-418e-aec8-086925dc7938} PushingToViews: Failed to push block to view test_5.v2 (7c22a887-3ed3-40f1-a092-d92463e4b87b), Stack size too large. Stack address: 0x7fb7fddf0000, frame address: 0x7fb7fe1ef100, stack size: 4198144, maximum stack size: 8388608 2025.07.28 11:52:30.563157 [ 17207 ] {843f77fd-10c6-418e-aec8-086925dc7938} PushingToViews: Failed to push block to view test_5.v1 (4ae2feef-b6fa-47ac-b20c-744da14b2a0a), Stack size too large. Stack address: 0x7fb7fddf0000, frame address: 0x7fb7fe1ef100, stack size: 4198144, maximum stack size: 8388608 2025.07.28 11:52:30.566699 [ 17207 ] {843f77fd-10c6-418e-aec8-086925dc7938} PushingToViews: Failed to push block to view test_5.v2 (7c22a887-3ed3-40f1-a092-d92463e4b87b), Stack size too large. Stack address: 0x7fb7fddf0000, frame address: 0x7fb7fe1ef100, stack size: 4198144, maximum stack size: 8388608 2025.07.28 11:52:30.571378 [ 17207 ] {843f77fd-10c6-418e-aec8-086925dc7938} PushingToViews: Failed to push block to view test_5.v1 (4ae2feef-b6fa-47ac-b20c-744da14b2a0a), Stack size too large. Stack address: 0x7fb7fddf0000, frame address: 0x7fb7fe1ef100, stack size: 4198144, maximum stack size: 8388608 2025.07.28 11:52:30.573322 [ 17207 ] {843f77fd-10c6-418e-aec8-086925dc7938} PushingToViews: Failed to push block to view test_5.v2 (7c22a887-3ed3-40f1-a092-d92463e4b87b), Stack size too large. Stack address: 0x7fb7fddf0000, frame address: 0x7fb7fe1ef100, stack size: 4198144, maximum stack size: 8388608 2025.07.28 11:52:30.583862 [ 17207 ] {843f77fd-10c6-418e-aec8-086925dc7938} PushingToViews: Failed to push block to view test_5.v1 (4ae2feef-b6fa-47ac-b20c-744da14b2a0a), Stack size too large. Stack address: 0x7fb7fddf0000, frame address: 0x7fb7fe1ef100, stack size: 4198144, maximum stack size: 8388608 2025.07.28 11:52:30.585970 [ 17207 ] {843f77fd-10c6-418e-aec8-086925dc7938} PushingToViews: Failed to push block to view test_5.v2 (7c22a887-3ed3-40f1-a092-d92463e4b87b), Stack size too large. Stack address: 0x7fb7fddf0000, frame address: 0x7fb7fe1ef100, stack size: 4198144, maximum stack size: 8388608 2025.07.28 11:52:30.588424 [ 17207 ] {843f77fd-10c6-418e-aec8-086925dc7938} PushingToViews: Failed to push block to view test_5.v1 (4ae2feef-b6fa-47ac-b20c-744da14b2a0a), Stack size too large. Stack address: 0x7fb7fddf0000, frame address: 0x7fb7fe1ef100, stack size: 4198144, maximum stack size: 8388608 2025.07.28 11:52:30.597924 [ 17207 ] {843f77fd-10c6-418e-aec8-086925dc7938} PushingToViews: Failed to push block to view test_5.v2 (7c22a887-3ed3-40f1-a092-d92463e4b87b), Stack size too large. Stack address: 0x7fb7fddf0000, frame address: 0x7fb7fe1ef100, stack size: 4198144, maximum stack size: 8388608 2025.07.28 11:52:30.604142 [ 17207 ] {843f77fd-10c6-418e-aec8-086925dc7938} PushingToViews: Failed to push block to view test_5.v1 (4ae2feef-b6fa-47ac-b20c-744da14b2a0a), Stack size too large. Stack address: 0x7fb7fddf0000, frame address: 0x7fb7fe1ef100, stack size: 4198144, maximum stack size: 8388608 2025.07.28 11:52:30.608583 [ 17207 ] {843f77fd-10c6-418e-aec8-086925dc7938} PushingToViews: Failed to push block to view test_5.v2 (7c22a887-3ed3-40f1-a092-d92463e4b87b), Stack size too large. Stack address: 0x7fb7fddf0000, frame address: 0x7fb7fe1ef100, stack size: 4198144, maximum stack size: 8388608 2025.07.28 11:52:30.610148 [ 17207 ] {843f77fd-10c6-418e-aec8-086925dc7938} PushingToViews: Failed to push block to view test_5.v1 (4ae2feef-b6fa-47ac-b20c-744da14b2a0a), Stack size too large. Stack address: 0x7fb7fddf0000, frame address: 0x7fb7fe1ef100, stack size: 4198144, maximum stack size: 8388608 2025.07.28 11:52:30.632299 [ 17207 ] {843f77fd-10c6-418e-aec8-086925dc7938} PushingToViews: Failed to push block to view test_5.v2 (7c22a887-3ed3-40f1-a092-d92463e4b87b), Stack size too large. Stack address: 0x7fb7fddf0000, frame address: 0x7fb7fe1ef100, stack size: 4198144, maximum stack size: 8388608 2025.07.28 11:52:30.637276 [ 17207 ] {843f77fd-10c6-418e-aec8-086925dc7938} PushingToViews: Failed to push block to view test_5.v1 (4ae2feef-b6fa-47ac-b20c-744da14b2a0a), Stack size too large. Stack address: 0x7fb7fddf0000, frame address: 0x7fb7fe1ef100, stack size: 4198144, maximum stack size: 8388608 2025.07.28 11:52:30.639211 [ 17207 ] {843f77fd-10c6-418e-aec8-086925dc7938} PushingToViews: Failed to push block to view test_5.v2 (7c22a887-3ed3-40f1-a092-d92463e4b87b), Stack size too large. Stack address: 0x7fb7fddf0000, frame address: 0x7fb7fe1ef100, stack size: 4198144, maximum stack size: 8388608 2025.07.28 11:52:30.651744 [ 17207 ] {843f77fd-10c6-418e-aec8-086925dc7938} PushingToViews: Failed to push block to view test_5.v1 (4ae2feef-b6fa-47ac-b20c-744da14b2a0a), Stack size too large. Stack address: 0x7fb7fddf0000, frame address: 0x7fb7fe1ef100, stack size: 4198144, maximum stack size: 8388608 2025.07.28 11:52:30.653435 [ 17207 ] {843f77fd-10c6-418e-aec8-086925dc7938} PushingToViews: Failed to push block to view test_5.v2 (7c22a887-3ed3-40f1-a092-d92463e4b87b), Stack size too large. Stack address: 0x7fb7fddf0000, frame address: 0x7fb7fe1ef100, stack size: 4198144, maximum stack size: 8388608 2025.07.28 11:52:30.664085 [ 17207 ] {843f77fd-10c6-418e-aec8-086925dc7938} PushingToViews: Failed to push block to view test_5.v1 (4ae2feef-b6fa-47ac-b20c-744da14b2a0a), Stack size too large. Stack address: 0x7fb7fddf0000, frame address: 0x7fb7fe1ef100, stack size: 4198144, maximum stack size: 8388608 2025.07.28 11:52:30.671899 [ 17207 ] {843f77fd-10c6-418e-aec8-086925dc7938} PushingToViews: Failed to push block to view test_5.v2 (7c22a887-3ed3-40f1-a092-d92463e4b87b), Stack size too large. Stack address: 0x7fb7fddf0000, frame address: 0x7fb7fe1ef100, stack size: 4198144, maximum stack size: 8388608 2025.07.28 11:52:30.673442 [ 17207 ] {843f77fd-10c6-418e-aec8-086925dc7938} PushingToViews: Failed to push block to view test_5.v1 (4ae2feef-b6fa-47ac-b20c-744da14b2a0a), Stack size too large. Stack address: 0x7fb7fddf0000, frame address: 0x7fb7fe1ef100, stack size: 4198144, maximum stack size: 8388608 2025.07.28 11:52:30.681194 [ 17207 ] {843f77fd-10c6-418e-aec8-086925dc7938} PushingToViews: Failed to push block to view test_5.v2 (7c22a887-3ed3-40f1-a092-d92463e4b87b), Stack size too large. Stack address: 0x7fb7fddf0000, frame address: 0x7fb7fe1ef100, stack size: 4198144, maximum stack size: 8388608 2025.07.28 11:52:30.684326 [ 17207 ] {843f77fd-10c6-418e-aec8-086925dc7938} PushingToViews: Failed to push block to view test_5.v1 (4ae2feef-b6fa-47ac-b20c-744da14b2a0a), Stack size too large. Stack address: 0x7fb7fddf0000, frame address: 0x7fb7fe1ef100, stack size: 4198144, maximum stack size: 8388608 2025.07.28 11:52:30.685644 [ 17207 ] {843f77fd-10c6-418e-aec8-086925dc7938} PushingToViews: Failed to push block to view test_5.v2 (7c22a887-3ed3-40f1-a092-d92463e4b87b), Stack size too large. Stack address: 0x7fb7fddf0000, frame address: 0x7fb7fe1ef100, stack size: 4198144, maximum stack size: 8388608 2025.07.28 11:52:30.687784 [ 17207 ] {843f77fd-10c6-418e-aec8-086925dc7938} PushingToViews: Failed to push block to view test_5.v1 (4ae2feef-b6fa-47ac-b20c-744da14b2a0a), Stack size too large. Stack address: 0x7fb7fddf0000, frame address: 0x7fb7fe1ef100, stack size: 4198144, maximum stack size: 8388608 2025.07.28 11:52:30.692150 [ 17207 ] {843f77fd-10c6-418e-aec8-086925dc7938} PushingToViews: Failed to push block to view test_5.v2 (7c22a887-3ed3-40f1-a092-d92463e4b87b), Stack size too large. Stack address: 0x7fb7fddf0000, frame address: 0x7fb7fe1ef100, stack size: 4198144, maximum stack size: 8388608 2025.07.28 11:52:30.693401 [ 17207 ] {843f77fd-10c6-418e-aec8-086925dc7938} PushingToViews: Failed to push block to view test_5.v1 (4ae2feef-b6fa-47ac-b20c-744da14b2a0a), Stack size too large. Stack address: 0x7fb7fddf0000, frame address: 0x7fb7fe1ef100, stack size: 4198144, maximum stack size: 8388608 2025.07.28 11:52:30.697702 [ 17207 ] {843f77fd-10c6-418e-aec8-086925dc7938} PushingToViews: Failed to push block to view test_5.v2 (7c22a887-3ed3-40f1-a092-d92463e4b87b), Stack size too large. Stack address: 0x7fb7fddf0000, frame address: 0x7fb7fe1ef100, stack size: 4198144, maximum stack size: 8388608 2025.07.28 11:52:30.698971 [ 3969 ] {} test_13.rmt2 (7f9b740d-015c-470e-8cc6-8ba33be0dc63): auto DB::StorageReplicatedMergeTree::processQueueEntry(ReplicatedMergeTreeQueue::SelectedEntryPtr)::(anonymous class)::operator()(LogEntryPtr &) const: Code: 86. DB::HTTPException: Received error from remote server http://146b4357c08d:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Ftest%2F01165%2Ftest_13%2Frmt%2Freplicas%2F1&part=20250728_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.6.10636.altinitytest (altinity build)) '. (RECEIVED_ERROR_FROM_REMOTE_IO_SERVER), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.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 const&, int&&, String const&, unsigned long&&, String const&) @ 0x000000000feda8d9 4. /build/src/IO/HTTPCommon.cpp:104: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x000000000feda6e2 5. /build/src/IO/HTTPCommon.cpp:93: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x000000000feda537 6. /build/src/IO/ReadWriteBufferFromHTTP.cpp:277: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x000000001184a4c4 7. /build/src/IO/ReadWriteBufferFromHTTP.cpp:285: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x000000001184a615 8. /build/src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x000000001184ae59 9. /build/src/IO/ReadWriteBufferFromHTTP.cpp:472: void std::__function::__policy_invoker::__call_impl[abi:se190107]>(std::__function::__policy_storage const*) @ 0x000000001184cedd 10. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001184858b 11. /build/src/IO/ReadWriteBufferFromHTTP.cpp:465: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x000000001184bf0b 12. /build/src/IO/ReadBuffer.h:60: DB::ReadBuffer::next() @ 0x000000000a148c7b 13. /build/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) @ 0x0000000011849fb2 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]>&)>&, 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&) @ 0x0000000011841980 15. /build/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) @ 0x000000001621208e 16. /build/src/Storages/StorageReplicatedMergeTree.cpp:5228: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl[abi:se190107] const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000015f9a5fe 17. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000015ed8bfd 18. /build/src/Storages/StorageReplicatedMergeTree.cpp:2514: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x0000000015ec9aab 19. /build/src/Storages/StorageReplicatedMergeTree.cpp:2349: DB::StorageReplicatedMergeTree::executeLogEntry(DB::ReplicatedMergeTreeLogEntry&) @ 0x0000000015eba91b 20. /build/src/Storages/StorageReplicatedMergeTree.cpp:3876: bool std::__function::__policy_invoker&)>::__call_impl[abi:se190107])::$_1, bool (std::shared_ptr&)>>(std::__function::__policy_storage const*, std::shared_ptr&) @ 0x0000000015f9837e 21. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000165d6fc3 22. /build/src/Storages/StorageReplicatedMergeTree.cpp:3872: DB::StorageReplicatedMergeTree::processQueueEntry(std::shared_ptr) @ 0x0000000015efc18a 23. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001624c1b2 24. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000162f9c70 25. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x00000000162fa55a 26. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc6653 27. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000000fccc4c3 28. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc3d92 29. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fcca080 30. ? @ 0x00007fbc6213eac3 31. ? @ 0x00007fbc621d0850 (version 25.3.6.10636.altinitytest (altinity build)) 2025.07.28 11:52:30.700980 [ 17207 ] {843f77fd-10c6-418e-aec8-086925dc7938} PushingToViews: Failed to push block to view test_5.v1 (4ae2feef-b6fa-47ac-b20c-744da14b2a0a), Stack size too large. Stack address: 0x7fb7fddf0000, frame address: 0x7fb7fe1ef100, stack size: 4198144, maximum stack size: 8388608 2025.07.28 11:52:30.702429 [ 17207 ] {843f77fd-10c6-418e-aec8-086925dc7938} PushingToViews: Failed to push block to view test_5.v2 (7c22a887-3ed3-40f1-a092-d92463e4b87b), Stack size too large. Stack address: 0x7fb7fddf0000, frame address: 0x7fb7fe1ef100, stack size: 4198144, maximum stack size: 8388608 2025.07.28 11:52:30.704342 [ 17207 ] {843f77fd-10c6-418e-aec8-086925dc7938} PushingToViews: Failed to push block to view test_5.v1 (4ae2feef-b6fa-47ac-b20c-744da14b2a0a), Stack size too large. Stack address: 0x7fb7fddf0000, frame address: 0x7fb7fe1ef100, stack size: 4198144, maximum stack size: 8388608 2025.07.28 11:52:30.707251 [ 17207 ] {843f77fd-10c6-418e-aec8-086925dc7938} PushingToViews: Failed to push block to view test_5.v2 (7c22a887-3ed3-40f1-a092-d92463e4b87b), Stack size too large. Stack address: 0x7fb7fddf0000, frame address: 0x7fb7fe1ef100, stack size: 4198144, maximum stack size: 8388608 2025.07.28 11:52:30.709933 [ 17207 ] {843f77fd-10c6-418e-aec8-086925dc7938} PushingToViews: Failed to push block to view test_5.v1 (4ae2feef-b6fa-47ac-b20c-744da14b2a0a), Stack size too large. Stack address: 0x7fb7fddf0000, frame address: 0x7fb7fe1ef100, stack size: 4198144, maximum stack size: 8388608 2025.07.28 11:52:30.711369 [ 17207 ] {843f77fd-10c6-418e-aec8-086925dc7938} PushingToViews: Failed to push block to view test_5.v2 (7c22a887-3ed3-40f1-a092-d92463e4b87b), Stack size too large. Stack address: 0x7fb7fddf0000, frame address: 0x7fb7fe1ef100, stack size: 4198144, maximum stack size: 8388608 2025.07.28 11:52:30.713047 [ 17207 ] {843f77fd-10c6-418e-aec8-086925dc7938} PushingToViews: Failed to push block to view test_5.v1 (4ae2feef-b6fa-47ac-b20c-744da14b2a0a), Stack size too large. Stack address: 0x7fb7fddf0000, frame address: 0x7fb7fe1ef100, stack size: 4198144, maximum stack size: 8388608 2025.07.28 11:52:30.715135 [ 17207 ] {843f77fd-10c6-418e-aec8-086925dc7938} PushingToViews: Failed to push block to view test_5.v2 (7c22a887-3ed3-40f1-a092-d92463e4b87b), Stack size too large. Stack address: 0x7fb7fddf0000, frame address: 0x7fb7fe1ef100, stack size: 4198144, maximum stack size: 8388608 2025.07.28 11:52:30.716764 [ 17207 ] {843f77fd-10c6-418e-aec8-086925dc7938} PushingToViews: Failed to push block to view test_5.v1 (4ae2feef-b6fa-47ac-b20c-744da14b2a0a), Stack size too large. Stack address: 0x7fb7fddf0000, frame address: 0x7fb7fe1ef100, stack size: 4198144, maximum stack size: 8388608 2025.07.28 11:52:30.718007 [ 17207 ] {843f77fd-10c6-418e-aec8-086925dc7938} PushingToViews: Failed to push block to view test_5.v2 (7c22a887-3ed3-40f1-a092-d92463e4b87b), Stack size too large. Stack address: 0x7fb7fddf0000, frame address: 0x7fb7fe1ef100, stack size: 4198144, maximum stack size: 8388608 2025.07.28 11:52:30.721551 [ 17207 ] {843f77fd-10c6-418e-aec8-086925dc7938} PushingToViews: Failed to push block to view test_5.v1 (4ae2feef-b6fa-47ac-b20c-744da14b2a0a), Stack size too large. Stack address: 0x7fb7fddf0000, frame address: 0x7fb7fe1ef100, stack size: 4198144, maximum stack size: 8388608 2025.07.28 11:52:30.724701 [ 17207 ] {843f77fd-10c6-418e-aec8-086925dc7938} PushingToViews: Failed to push block to view test_5.v2 (7c22a887-3ed3-40f1-a092-d92463e4b87b), Stack size too large. Stack address: 0x7fb7fddf0000, frame address: 0x7fb7fe1ef100, stack size: 4198144, maximum stack size: 8388608 2025.07.28 11:52:30.730781 [ 17207 ] {843f77fd-10c6-418e-aec8-086925dc7938} PushingToViews: Failed to push block to view test_5.v1 (4ae2feef-b6fa-47ac-b20c-744da14b2a0a), Stack size too large. Stack address: 0x7fb7fddf0000, frame address: 0x7fb7fe1ef100, stack size: 4198144, maximum stack size: 8388608 2025.07.28 11:52:30.738438 [ 17207 ] {843f77fd-10c6-418e-aec8-086925dc7938} PushingToViews: Failed to push block to view test_5.v2 (7c22a887-3ed3-40f1-a092-d92463e4b87b), Stack size too large. Stack address: 0x7fb7fddf0000, frame address: 0x7fb7fe1ef100, stack size: 4198144, maximum stack size: 8388608 2025.07.28 11:52:30.740873 [ 17207 ] {843f77fd-10c6-418e-aec8-086925dc7938} PushingToViews: Failed to push block to view test_5.v1 (4ae2feef-b6fa-47ac-b20c-744da14b2a0a), Stack size too large. Stack address: 0x7fb7fddf0000, frame address: 0x7fb7fe1ef100, stack size: 4198144, maximum stack size: 8388608 2025.07.28 11:52:30.742478 [ 17207 ] {843f77fd-10c6-418e-aec8-086925dc7938} PushingToViews: Failed to push block to view test_5.v2 (7c22a887-3ed3-40f1-a092-d92463e4b87b), Stack size too large. Stack address: 0x7fb7fddf0000, frame address: 0x7fb7fe1ef100, stack size: 4198144, maximum stack size: 8388608 2025.07.28 11:52:30.745162 [ 17207 ] {843f77fd-10c6-418e-aec8-086925dc7938} PushingToViews: Failed to push block to view test_5.v1 (4ae2feef-b6fa-47ac-b20c-744da14b2a0a), Stack size too large. Stack address: 0x7fb7fddf0000, frame address: 0x7fb7fe1ef100, stack size: 4198144, maximum stack size: 8388608 2025.07.28 11:52:30.755816 [ 17207 ] {843f77fd-10c6-418e-aec8-086925dc7938} PushingToViews: Failed to push block to view test_5.v2 (7c22a887-3ed3-40f1-a092-d92463e4b87b), Stack size too large. Stack address: 0x7fb7fddf0000, frame address: 0x7fb7fe1ef100, stack size: 4198144, maximum stack size: 8388608 2025.07.28 11:52:30.759121 [ 17207 ] {843f77fd-10c6-418e-aec8-086925dc7938} PushingToViews: Failed to push block to view test_5.v1 (4ae2feef-b6fa-47ac-b20c-744da14b2a0a), Stack size too large. Stack address: 0x7fb7fddf0000, frame address: 0x7fb7fe1ef100, stack size: 4198144, maximum stack size: 8388608 2025.07.28 11:52:30.761108 [ 17207 ] {843f77fd-10c6-418e-aec8-086925dc7938} PushingToViews: Failed to push block to view test_5.v2 (7c22a887-3ed3-40f1-a092-d92463e4b87b), Stack size too large. Stack address: 0x7fb7fddf0000, frame address: 0x7fb7fe1ef100, stack size: 4198144, maximum stack size: 8388608 2025.07.28 11:52:30.763500 [ 17207 ] {843f77fd-10c6-418e-aec8-086925dc7938} PushingToViews: Failed to push block to view test_5.v1 (4ae2feef-b6fa-47ac-b20c-744da14b2a0a), Stack size too large. Stack address: 0x7fb7fddf0000, frame address: 0x7fb7fe1ef100, stack size: 4198144, maximum stack size: 8388608 2025.07.28 11:52:30.764751 [ 17207 ] {843f77fd-10c6-418e-aec8-086925dc7938} PushingToViews: Failed to push block to view test_5.v2 (7c22a887-3ed3-40f1-a092-d92463e4b87b), Stack size too large. Stack address: 0x7fb7fddf0000, frame address: 0x7fb7fe1ef100, stack size: 4198144, maximum stack size: 8388608 2025.07.28 11:52:30.772242 [ 17207 ] {843f77fd-10c6-418e-aec8-086925dc7938} PushingToViews: Failed to push block to view test_5.v1 (4ae2feef-b6fa-47ac-b20c-744da14b2a0a), Stack size too large. Stack address: 0x7fb7fddf0000, frame address: 0x7fb7fe1ef100, stack size: 4198144, maximum stack size: 8388608 2025.07.28 11:52:30.776334 [ 17207 ] {843f77fd-10c6-418e-aec8-086925dc7938} PushingToViews: Failed to push block to view test_5.v2 (7c22a887-3ed3-40f1-a092-d92463e4b87b), Stack size too large. Stack address: 0x7fb7fddf0000, frame address: 0x7fb7fe1ef100, stack size: 4198144, maximum stack size: 8388608 2025.07.28 11:52:30.785326 [ 17207 ] {843f77fd-10c6-418e-aec8-086925dc7938} PushingToViews: Failed to push block to view test_5.v1 (4ae2feef-b6fa-47ac-b20c-744da14b2a0a), Stack size too large. Stack address: 0x7fb7fddf0000, frame address: 0x7fb7fe1ef100, stack size: 4198144, maximum stack size: 8388608 2025.07.28 11:52:30.795489 [ 17207 ] {843f77fd-10c6-418e-aec8-086925dc7938} PushingToViews: Failed to push block to view test_5.v2 (7c22a887-3ed3-40f1-a092-d92463e4b87b), Stack size too large. Stack address: 0x7fb7fddf0000, frame address: 0x7fb7fe1ef100, stack size: 4198144, maximum stack size: 8388608 2025.07.28 11:52:30.796634 [ 17207 ] {843f77fd-10c6-418e-aec8-086925dc7938} PushingToViews: Failed to push block to view test_5.v1 (4ae2feef-b6fa-47ac-b20c-744da14b2a0a), Stack size too large. Stack address: 0x7fb7fddf0000, frame address: 0x7fb7fe1ef100, stack size: 4198144, maximum stack size: 8388608 2025.07.28 11:52:30.798743 [ 17207 ] {843f77fd-10c6-418e-aec8-086925dc7938} PushingToViews: Failed to push block to view test_5.v2 (7c22a887-3ed3-40f1-a092-d92463e4b87b), Stack size too large. Stack address: 0x7fb7fddf0000, frame address: 0x7fb7fe1ef100, stack size: 4198144, maximum stack size: 8388608 2025.07.28 11:52:30.799661 [ 17207 ] {843f77fd-10c6-418e-aec8-086925dc7938} PushingToViews: Failed to push block to view test_5.v1 (4ae2feef-b6fa-47ac-b20c-744da14b2a0a), Stack size too large. Stack address: 0x7fb7fddf0000, frame address: 0x7fb7fe1ef100, stack size: 4198144, maximum stack size: 8388608 2025.07.28 11:52:30.801262 [ 17207 ] {843f77fd-10c6-418e-aec8-086925dc7938} PushingToViews: Failed to push block to view test_5.v2 (7c22a887-3ed3-40f1-a092-d92463e4b87b), Stack size too large. Stack address: 0x7fb7fddf0000, frame address: 0x7fb7fe1ef100, stack size: 4198144, maximum stack size: 8388608 2025.07.28 11:52:30.803887 [ 17207 ] {843f77fd-10c6-418e-aec8-086925dc7938} PushingToViews: Failed to push block to view test_5.v1 (4ae2feef-b6fa-47ac-b20c-744da14b2a0a), Stack size too large. Stack address: 0x7fb7fddf0000, frame address: 0x7fb7fe1ef100, stack size: 4198144, maximum stack size: 8388608 2025.07.28 11:52:30.805582 [ 17207 ] {843f77fd-10c6-418e-aec8-086925dc7938} PushingToViews: Failed to push block to view test_5.v2 (7c22a887-3ed3-40f1-a092-d92463e4b87b), Stack size too large. Stack address: 0x7fb7fddf0000, frame address: 0x7fb7fe1ef100, stack size: 4198144, maximum stack size: 8388608 2025.07.28 11:52:30.806988 [ 17207 ] {843f77fd-10c6-418e-aec8-086925dc7938} PushingToViews: Failed to push block to view test_5.v1 (4ae2feef-b6fa-47ac-b20c-744da14b2a0a), Stack size too large. Stack address: 0x7fb7fddf0000, frame address: 0x7fb7fe1ef100, stack size: 4198144, maximum stack size: 8388608 2025.07.28 11:52:30.808280 [ 17207 ] {843f77fd-10c6-418e-aec8-086925dc7938} PushingToViews: Failed to push block to view test_5.v2 (7c22a887-3ed3-40f1-a092-d92463e4b87b), Stack size too large. Stack address: 0x7fb7fddf0000, frame address: 0x7fb7fe1ef100, stack size: 4198144, maximum stack size: 8388608 2025.07.28 11:52:30.825910 [ 17207 ] {843f77fd-10c6-418e-aec8-086925dc7938} PushingToViews: Failed to push block to view test_5.v1 (4ae2feef-b6fa-47ac-b20c-744da14b2a0a), Stack size too large. Stack address: 0x7fb7fddf0000, frame address: 0x7fb7fe1ef100, stack size: 4198144, maximum stack size: 8388608 2025.07.28 11:52:30.831701 [ 17207 ] {843f77fd-10c6-418e-aec8-086925dc7938} PushingToViews: Failed to push block to view test_5.v2 (7c22a887-3ed3-40f1-a092-d92463e4b87b), Stack size too large. Stack address: 0x7fb7fddf0000, frame address: 0x7fb7fe1ef100, stack size: 4198144, maximum stack size: 8388608 2025.07.28 11:52:30.833467 [ 17207 ] {843f77fd-10c6-418e-aec8-086925dc7938} PushingToViews: Failed to push block to view test_5.v1 (4ae2feef-b6fa-47ac-b20c-744da14b2a0a), Stack size too large. Stack address: 0x7fb7fddf0000, frame address: 0x7fb7fe1ef100, stack size: 4198144, maximum stack size: 8388608 2025.07.28 11:52:30.837105 [ 17207 ] {843f77fd-10c6-418e-aec8-086925dc7938} PushingToViews: Failed to push block to view test_5.v2 (7c22a887-3ed3-40f1-a092-d92463e4b87b), Stack size too large. Stack address: 0x7fb7fddf0000, frame address: 0x7fb7fe1ef100, stack size: 4198144, maximum stack size: 8388608 2025.07.28 11:52:30.839311 [ 17207 ] {843f77fd-10c6-418e-aec8-086925dc7938} PushingToViews: Failed to push block to view test_5.v1 (4ae2feef-b6fa-47ac-b20c-744da14b2a0a), Stack size too large. Stack address: 0x7fb7fddf0000, frame address: 0x7fb7fe1ef100, stack size: 4198144, maximum stack size: 8388608 2025.07.28 11:52:30.841092 [ 17207 ] {843f77fd-10c6-418e-aec8-086925dc7938} PushingToViews: Failed to push block to view test_5.v2 (7c22a887-3ed3-40f1-a092-d92463e4b87b), Stack size too large. Stack address: 0x7fb7fddf0000, frame address: 0x7fb7fe1ef100, stack size: 4198144, maximum stack size: 8388608 2025.07.28 11:52:30.843017 [ 17207 ] {843f77fd-10c6-418e-aec8-086925dc7938} PushingToViews: Failed to push block to view test_5.v1 (4ae2feef-b6fa-47ac-b20c-744da14b2a0a), Stack size too large. Stack address: 0x7fb7fddf0000, frame address: 0x7fb7fe1ef100, stack size: 4198144, maximum stack size: 8388608 2025.07.28 11:52:30.847170 [ 17207 ] {843f77fd-10c6-418e-aec8-086925dc7938} PushingToViews: Failed to push block to view test_5.v2 (7c22a887-3ed3-40f1-a092-d92463e4b87b), Stack size too large. Stack address: 0x7fb7fddf0000, frame address: 0x7fb7fe1ef100, stack size: 4198144, maximum stack size: 8388608 2025.07.28 11:52:30.861740 [ 17207 ] {843f77fd-10c6-418e-aec8-086925dc7938} PushingToViews: Failed to push block to view test_5.v1 (4ae2feef-b6fa-47ac-b20c-744da14b2a0a), Stack size too large. Stack address: 0x7fb7fddf0000, frame address: 0x7fb7fe1ef100, stack size: 4198144, maximum stack size: 8388608 2025.07.28 11:52:30.863170 [ 17207 ] {843f77fd-10c6-418e-aec8-086925dc7938} PushingToViews: Failed to push block to view test_5.v2 (7c22a887-3ed3-40f1-a092-d92463e4b87b), Stack size too large. Stack address: 0x7fb7fddf0000, frame address: 0x7fb7fe1ef100, stack size: 4198144, maximum stack size: 8388608 2025.07.28 11:52:30.864356 [ 17207 ] {843f77fd-10c6-418e-aec8-086925dc7938} PushingToViews: Failed to push block to view test_5.v1 (4ae2feef-b6fa-47ac-b20c-744da14b2a0a), Stack size too large. Stack address: 0x7fb7fddf0000, frame address: 0x7fb7fe1ef100, stack size: 4198144, maximum stack size: 8388608 2025.07.28 11:52:30.873931 [ 17207 ] {843f77fd-10c6-418e-aec8-086925dc7938} PushingToViews: Failed to push block to view test_5.v2 (7c22a887-3ed3-40f1-a092-d92463e4b87b), Stack size too large. Stack address: 0x7fb7fddf0000, frame address: 0x7fb7fe1ef100, stack size: 4198144, maximum stack size: 8388608 2025.07.28 11:52:30.875634 [ 17207 ] {843f77fd-10c6-418e-aec8-086925dc7938} PushingToViews: Failed to push block to view test_5.v1 (4ae2feef-b6fa-47ac-b20c-744da14b2a0a), Stack size too large. Stack address: 0x7fb7fddf0000, frame address: 0x7fb7fe1ef100, stack size: 4198144, maximum stack size: 8388608 2025.07.28 11:52:30.876675 [ 17207 ] {843f77fd-10c6-418e-aec8-086925dc7938} PushingToViews: Failed to push block to view test_5.v2 (7c22a887-3ed3-40f1-a092-d92463e4b87b), Stack size too large. Stack address: 0x7fb7fddf0000, frame address: 0x7fb7fe1ef100, stack size: 4198144, maximum stack size: 8388608 2025.07.28 11:52:30.879149 [ 17207 ] {843f77fd-10c6-418e-aec8-086925dc7938} PushingToViews: Failed to push block to view test_5.v1 (4ae2feef-b6fa-47ac-b20c-744da14b2a0a), Stack size too large. Stack address: 0x7fb7fddf0000, frame address: 0x7fb7fe1ef100, stack size: 4198144, maximum stack size: 8388608 2025.07.28 11:52:30.880843 [ 17207 ] {843f77fd-10c6-418e-aec8-086925dc7938} PushingToViews: Failed to push block to view test_5.v2 (7c22a887-3ed3-40f1-a092-d92463e4b87b), Stack size too large. Stack address: 0x7fb7fddf0000, frame address: 0x7fb7fe1ef100, stack size: 4198144, maximum stack size: 8388608 2025.07.28 11:52:30.882344 [ 17207 ] {843f77fd-10c6-418e-aec8-086925dc7938} PushingToViews: Failed to push block to view test_5.v1 (4ae2feef-b6fa-47ac-b20c-744da14b2a0a), Stack size too large. Stack address: 0x7fb7fddf0000, frame address: 0x7fb7fe1ef100, stack size: 4198144, maximum stack size: 8388608 2025.07.28 11:52:30.885096 [ 17207 ] {843f77fd-10c6-418e-aec8-086925dc7938} PushingToViews: Failed to push block to view test_5.v2 (7c22a887-3ed3-40f1-a092-d92463e4b87b), Stack size too large. Stack address: 0x7fb7fddf0000, frame address: 0x7fb7fe1ef100, stack size: 4198144, maximum stack size: 8388608 2025.07.28 11:52:30.887545 [ 17207 ] {843f77fd-10c6-418e-aec8-086925dc7938} PushingToViews: Failed to push block to view test_5.v1 (4ae2feef-b6fa-47ac-b20c-744da14b2a0a), Stack size too large. Stack address: 0x7fb7fddf0000, frame address: 0x7fb7fe1ef100, stack size: 4198144, maximum stack size: 8388608 2025.07.28 11:52:30.889281 [ 17207 ] {843f77fd-10c6-418e-aec8-086925dc7938} PushingToViews: Failed to push block to view test_5.v2 (7c22a887-3ed3-40f1-a092-d92463e4b87b), Stack size too large. Stack address: 0x7fb7fddf0000, frame address: 0x7fb7fe1ef100, stack size: 4198144, maximum stack size: 8388608 2025.07.28 11:52:30.915182 [ 17207 ] {843f77fd-10c6-418e-aec8-086925dc7938} PushingToViews: Failed to push block to view test_5.v1 (4ae2feef-b6fa-47ac-b20c-744da14b2a0a), Stack size too large. Stack address: 0x7fb7fddf0000, frame address: 0x7fb7fe1ef100, stack size: 4198144, maximum stack size: 8388608 2025.07.28 11:52:30.918320 [ 17207 ] {843f77fd-10c6-418e-aec8-086925dc7938} PushingToViews: Failed to push block to view test_5.v2 (7c22a887-3ed3-40f1-a092-d92463e4b87b), Stack size too large. Stack address: 0x7fb7fddf0000, frame address: 0x7fb7fe1ef100, stack size: 4198144, maximum stack size: 8388608 2025.07.28 11:52:30.924508 [ 17207 ] {843f77fd-10c6-418e-aec8-086925dc7938} PushingToViews: Failed to push block to view test_5.v1 (4ae2feef-b6fa-47ac-b20c-744da14b2a0a), Stack size too large. Stack address: 0x7fb7fddf0000, frame address: 0x7fb7fe1ef100, stack size: 4198144, maximum stack size: 8388608 2025.07.28 11:52:30.925516 [ 17207 ] {843f77fd-10c6-418e-aec8-086925dc7938} PushingToViews: Failed to push block to view test_5.v2 (7c22a887-3ed3-40f1-a092-d92463e4b87b), Stack size too large. Stack address: 0x7fb7fddf0000, frame address: 0x7fb7fe1ef100, stack size: 4198144, maximum stack size: 8388608 2025.07.28 11:52:30.927993 [ 17207 ] {843f77fd-10c6-418e-aec8-086925dc7938} PushingToViews: Failed to push block to view test_5.v1 (4ae2feef-b6fa-47ac-b20c-744da14b2a0a), Stack size too large. Stack address: 0x7fb7fddf0000, frame address: 0x7fb7fe1ef100, stack size: 4198144, maximum stack size: 8388608 2025.07.28 11:52:30.929346 [ 17207 ] {843f77fd-10c6-418e-aec8-086925dc7938} PushingToViews: Failed to push block to view test_5.v2 (7c22a887-3ed3-40f1-a092-d92463e4b87b), Stack size too large. Stack address: 0x7fb7fddf0000, frame address: 0x7fb7fe1ef100, stack size: 4198144, maximum stack size: 8388608 2025.07.28 11:52:30.930517 [ 17207 ] {843f77fd-10c6-418e-aec8-086925dc7938} PushingToViews: Failed to push block to view test_5.v1 (4ae2feef-b6fa-47ac-b20c-744da14b2a0a), Stack size too large. Stack address: 0x7fb7fddf0000, frame address: 0x7fb7fe1ef100, stack size: 4198144, maximum stack size: 8388608 2025.07.28 11:52:30.931728 [ 17207 ] {843f77fd-10c6-418e-aec8-086925dc7938} PushingToViews: Failed to push block to view test_5.v2 (7c22a887-3ed3-40f1-a092-d92463e4b87b), Stack size too large. Stack address: 0x7fb7fddf0000, frame address: 0x7fb7fe1ef100, stack size: 4198144, maximum stack size: 8388608 2025.07.28 11:52:30.933669 [ 17207 ] {843f77fd-10c6-418e-aec8-086925dc7938} PushingToViews: Failed to push block to view test_5.v1 (4ae2feef-b6fa-47ac-b20c-744da14b2a0a), Stack size too large. Stack address: 0x7fb7fddf0000, frame address: 0x7fb7fe1ef100, stack size: 4198144, maximum stack size: 8388608 2025.07.28 11:52:30.934777 [ 17207 ] {843f77fd-10c6-418e-aec8-086925dc7938} PushingToViews: Failed to push block to view test_5.v2 (7c22a887-3ed3-40f1-a092-d92463e4b87b), Stack size too large. Stack address: 0x7fb7fddf0000, frame address: 0x7fb7fe1ef100, stack size: 4198144, maximum stack size: 8388608 2025.07.28 11:52:30.935881 [ 17207 ] {843f77fd-10c6-418e-aec8-086925dc7938} PushingToViews: Failed to push block to view test_5.v1 (4ae2feef-b6fa-47ac-b20c-744da14b2a0a), Stack size too large. Stack address: 0x7fb7fddf0000, frame address: 0x7fb7fe1ef100, stack size: 4198144, maximum stack size: 8388608 2025.07.28 11:52:30.937846 [ 17207 ] {843f77fd-10c6-418e-aec8-086925dc7938} PushingToViews: Failed to push block to view test_5.v2 (7c22a887-3ed3-40f1-a092-d92463e4b87b), Stack size too large. Stack address: 0x7fb7fddf0000, frame address: 0x7fb7fe1ef100, stack size: 4198144, maximum stack size: 8388608 2025.07.28 11:52:30.938775 [ 17207 ] {843f77fd-10c6-418e-aec8-086925dc7938} PushingToViews: Failed to push block to view test_5.v1 (4ae2feef-b6fa-47ac-b20c-744da14b2a0a), Stack size too large. Stack address: 0x7fb7fddf0000, frame address: 0x7fb7fe1ef100, stack size: 4198144, maximum stack size: 8388608 2025.07.28 11:52:30.941654 [ 17207 ] {843f77fd-10c6-418e-aec8-086925dc7938} PushingToViews: Failed to push block to view test_5.v2 (7c22a887-3ed3-40f1-a092-d92463e4b87b), Stack size too large. Stack address: 0x7fb7fddf0000, frame address: 0x7fb7fe1ef100, stack size: 4198144, maximum stack size: 8388608 2025.07.28 11:52:30.943403 [ 17207 ] {843f77fd-10c6-418e-aec8-086925dc7938} PushingToViews: Failed to push block to view test_5.v1 (4ae2feef-b6fa-47ac-b20c-744da14b2a0a), Stack size too large. Stack address: 0x7fb7fddf0000, frame address: 0x7fb7fe1ef100, stack size: 4198144, maximum stack size: 8388608 2025.07.28 11:52:30.949977 [ 17207 ] {843f77fd-10c6-418e-aec8-086925dc7938} PushingToViews: Failed to push block to view test_5.v2 (7c22a887-3ed3-40f1-a092-d92463e4b87b), Stack size too large. Stack address: 0x7fb7fddf0000, frame address: 0x7fb7fe1ef100, stack size: 4198144, maximum stack size: 8388608 2025.07.28 11:52:30.951239 [ 17207 ] {843f77fd-10c6-418e-aec8-086925dc7938} PushingToViews: Failed to push block to view test_5.v1 (4ae2feef-b6fa-47ac-b20c-744da14b2a0a), Stack size too large. Stack address: 0x7fb7fddf0000, frame address: 0x7fb7fe1ef100, stack size: 4198144, maximum stack size: 8388608 2025.07.28 11:52:30.952047 [ 17207 ] {843f77fd-10c6-418e-aec8-086925dc7938} PushingToViews: Failed to push block to view test_5.v2 (7c22a887-3ed3-40f1-a092-d92463e4b87b), Stack size too large. Stack address: 0x7fb7fddf0000, frame address: 0x7fb7fe1ef100, stack size: 4198144, maximum stack size: 8388608 2025.07.28 11:52:30.953585 [ 17207 ] {843f77fd-10c6-418e-aec8-086925dc7938} PushingToViews: Failed to push block to view test_5.v1 (4ae2feef-b6fa-47ac-b20c-744da14b2a0a), Stack size too large. Stack address: 0x7fb7fddf0000, frame address: 0x7fb7fe1ef100, stack size: 4198144, maximum stack size: 8388608 2025.07.28 11:52:30.954666 [ 17207 ] {843f77fd-10c6-418e-aec8-086925dc7938} PushingToViews: Failed to push block to view test_5.v2 (7c22a887-3ed3-40f1-a092-d92463e4b87b), Stack size too large. Stack address: 0x7fb7fddf0000, frame address: 0x7fb7fe1ef100, stack size: 4198144, maximum stack size: 8388608 2025.07.28 11:52:30.955472 [ 17207 ] {843f77fd-10c6-418e-aec8-086925dc7938} PushingToViews: Failed to push block to view test_5.v1 (4ae2feef-b6fa-47ac-b20c-744da14b2a0a), Stack size too large. Stack address: 0x7fb7fddf0000, frame address: 0x7fb7fe1ef100, stack size: 4198144, maximum stack size: 8388608 2025.07.28 11:52:30.957129 [ 17207 ] {843f77fd-10c6-418e-aec8-086925dc7938} PushingToViews: Failed to push block to view test_5.v2 (7c22a887-3ed3-40f1-a092-d92463e4b87b), Stack size too large. Stack address: 0x7fb7fddf0000, frame address: 0x7fb7fe1ef100, stack size: 4198144, maximum stack size: 8388608 2025.07.28 11:52:30.958098 [ 17207 ] {843f77fd-10c6-418e-aec8-086925dc7938} PushingToViews: Failed to push block to view test_5.v1 (4ae2feef-b6fa-47ac-b20c-744da14b2a0a), Stack size too large. Stack address: 0x7fb7fddf0000, frame address: 0x7fb7fe1ef100, stack size: 4198144, maximum stack size: 8388608 2025.07.28 11:52:30.959083 [ 17207 ] {843f77fd-10c6-418e-aec8-086925dc7938} PushingToViews: Failed to push block to view test_5.v2 (7c22a887-3ed3-40f1-a092-d92463e4b87b), Stack size too large. Stack address: 0x7fb7fddf0000, frame address: 0x7fb7fe1ef100, stack size: 4198144, maximum stack size: 8388608 2025.07.28 11:52:30.961640 [ 17207 ] {843f77fd-10c6-418e-aec8-086925dc7938} PushingToViews: Failed to push block to view test_5.v1 (4ae2feef-b6fa-47ac-b20c-744da14b2a0a), Stack size too large. Stack address: 0x7fb7fddf0000, frame address: 0x7fb7fe1ef100, stack size: 4198144, maximum stack size: 8388608 2025.07.28 11:52:30.962902 [ 17207 ] {843f77fd-10c6-418e-aec8-086925dc7938} PushingToViews: Failed to push block to view test_5.v2 (7c22a887-3ed3-40f1-a092-d92463e4b87b), Stack size too large. Stack address: 0x7fb7fddf0000, frame address: 0x7fb7fe1ef100, stack size: 4198144, maximum stack size: 8388608 2025.07.28 11:52:30.964641 [ 17207 ] {843f77fd-10c6-418e-aec8-086925dc7938} PushingToViews: Failed to push block to view test_5.v1 (4ae2feef-b6fa-47ac-b20c-744da14b2a0a), Stack size too large. Stack address: 0x7fb7fddf0000, frame address: 0x7fb7fe1ef100, stack size: 4198144, maximum stack size: 8388608 2025.07.28 11:52:30.965808 [ 17207 ] {843f77fd-10c6-418e-aec8-086925dc7938} PushingToViews: Failed to push block to view test_5.v2 (7c22a887-3ed3-40f1-a092-d92463e4b87b), Stack size too large. Stack address: 0x7fb7fddf0000, frame address: 0x7fb7fe1ef100, stack size: 4198144, maximum stack size: 8388608 2025.07.28 11:52:30.967054 [ 17207 ] {843f77fd-10c6-418e-aec8-086925dc7938} PushingToViews: Failed to push block to view test_5.v1 (4ae2feef-b6fa-47ac-b20c-744da14b2a0a), Stack size too large. Stack address: 0x7fb7fddf0000, frame address: 0x7fb7fe1ef100, stack size: 4198144, maximum stack size: 8388608 2025.07.28 11:52:30.968082 [ 17207 ] {843f77fd-10c6-418e-aec8-086925dc7938} PushingToViews: Failed to push block to view test_5.v2 (7c22a887-3ed3-40f1-a092-d92463e4b87b), Stack size too large. Stack address: 0x7fb7fddf0000, frame address: 0x7fb7fe1ef100, stack size: 4198144, maximum stack size: 8388608 2025.07.28 11:52:30.969429 [ 17207 ] {843f77fd-10c6-418e-aec8-086925dc7938} PushingToViews: Failed to push block to view test_5.v1 (4ae2feef-b6fa-47ac-b20c-744da14b2a0a), Stack size too large. Stack address: 0x7fb7fddf0000, frame address: 0x7fb7fe1ef100, stack size: 4198144, maximum stack size: 8388608 2025.07.28 11:52:30.970614 [ 17207 ] {843f77fd-10c6-418e-aec8-086925dc7938} PushingToViews: Failed to push block to view test_5.v2 (7c22a887-3ed3-40f1-a092-d92463e4b87b), Stack size too large. Stack address: 0x7fb7fddf0000, frame address: 0x7fb7fe1ef100, stack size: 4198144, maximum stack size: 8388608 2025.07.28 11:52:30.971414 [ 17207 ] {843f77fd-10c6-418e-aec8-086925dc7938} PushingToViews: Failed to push block to view test_5.v1 (4ae2feef-b6fa-47ac-b20c-744da14b2a0a), Stack size too large. Stack address: 0x7fb7fddf0000, frame address: 0x7fb7fe1ef100, stack size: 4198144, maximum stack size: 8388608 2025.07.28 11:52:30.972409 [ 17207 ] {843f77fd-10c6-418e-aec8-086925dc7938} PushingToViews: Failed to push block to view test_5.v2 (7c22a887-3ed3-40f1-a092-d92463e4b87b), Stack size too large. Stack address: 0x7fb7fddf0000, frame address: 0x7fb7fe1ef100, stack size: 4198144, maximum stack size: 8388608 2025.07.28 11:52:30.974461 [ 17207 ] {843f77fd-10c6-418e-aec8-086925dc7938} PushingToViews: Failed to push block to view test_5.v1 (4ae2feef-b6fa-47ac-b20c-744da14b2a0a), Stack size too large. Stack address: 0x7fb7fddf0000, frame address: 0x7fb7fe1ef100, stack size: 4198144, maximum stack size: 8388608 2025.07.28 11:52:30.975638 [ 17207 ] {843f77fd-10c6-418e-aec8-086925dc7938} PushingToViews: Failed to push block to view test_5.v2 (7c22a887-3ed3-40f1-a092-d92463e4b87b), Stack size too large. Stack address: 0x7fb7fddf0000, frame address: 0x7fb7fe1ef100, stack size: 4198144, maximum stack size: 8388608 2025.07.28 11:52:30.976768 [ 17207 ] {843f77fd-10c6-418e-aec8-086925dc7938} PushingToViews: Failed to push block to view test_5.v1 (4ae2feef-b6fa-47ac-b20c-744da14b2a0a), Stack size too large. Stack address: 0x7fb7fddf0000, frame address: 0x7fb7fe1ef100, stack size: 4198144, maximum stack size: 8388608 2025.07.28 11:52:30.978548 [ 17207 ] {843f77fd-10c6-418e-aec8-086925dc7938} PushingToViews: Failed to push block to view test_5.v2 (7c22a887-3ed3-40f1-a092-d92463e4b87b), Stack size too large. Stack address: 0x7fb7fddf0000, frame address: 0x7fb7fe1ef100, stack size: 4198144, maximum stack size: 8388608 2025.07.28 11:52:30.980142 [ 17207 ] {843f77fd-10c6-418e-aec8-086925dc7938} PushingToViews: Failed to push block to view test_5.v1 (4ae2feef-b6fa-47ac-b20c-744da14b2a0a), Stack size too large. Stack address: 0x7fb7fddf0000, frame address: 0x7fb7fe1ef100, stack size: 4198144, maximum stack size: 8388608 2025.07.28 11:52:31.050396 [ 17207 ] {843f77fd-10c6-418e-aec8-086925dc7938} PushingToViews: Failed to push block to view test_5.v2 (7c22a887-3ed3-40f1-a092-d92463e4b87b), Stack size too large. Stack address: 0x7fb7fddf0000, frame address: 0x7fb7fe1ef100, stack size: 4198144, maximum stack size: 8388608 2025.07.28 11:52:31.053117 [ 17207 ] {843f77fd-10c6-418e-aec8-086925dc7938} PushingToViews: Failed to push block to view test_5.v1 (4ae2feef-b6fa-47ac-b20c-744da14b2a0a), Stack size too large. Stack address: 0x7fb7fddf0000, frame address: 0x7fb7fe1ef100, stack size: 4198144, maximum stack size: 8388608 2025.07.28 11:52:31.063275 [ 17207 ] {843f77fd-10c6-418e-aec8-086925dc7938} PushingToViews: Failed to push block to view test_5.v2 (7c22a887-3ed3-40f1-a092-d92463e4b87b), Stack size too large. Stack address: 0x7fb7fddf0000, frame address: 0x7fb7fe1ef100, stack size: 4198144, maximum stack size: 8388608 2025.07.28 11:52:31.065085 [ 17207 ] {843f77fd-10c6-418e-aec8-086925dc7938} PushingToViews: Failed to push block to view test_5.v1 (4ae2feef-b6fa-47ac-b20c-744da14b2a0a), Stack size too large. Stack address: 0x7fb7fddf0000, frame address: 0x7fb7fe1ef100, stack size: 4198144, maximum stack size: 8388608 2025.07.28 11:52:31.066304 [ 17207 ] {843f77fd-10c6-418e-aec8-086925dc7938} PushingToViews: Failed to push block to view test_5.v2 (7c22a887-3ed3-40f1-a092-d92463e4b87b), Stack size too large. Stack address: 0x7fb7fddf0000, frame address: 0x7fb7fe1ef100, stack size: 4198144, maximum stack size: 8388608 2025.07.28 11:52:31.068359 [ 17207 ] {843f77fd-10c6-418e-aec8-086925dc7938} PushingToViews: Failed to push block to view test_5.v1 (4ae2feef-b6fa-47ac-b20c-744da14b2a0a), Stack size too large. Stack address: 0x7fb7fddf0000, frame address: 0x7fb7fe1ef100, stack size: 4198144, maximum stack size: 8388608 2025.07.28 11:52:31.070050 [ 17207 ] {843f77fd-10c6-418e-aec8-086925dc7938} PushingToViews: Failed to push block to view test_5.v2 (7c22a887-3ed3-40f1-a092-d92463e4b87b), Stack size too large. Stack address: 0x7fb7fddf0000, frame address: 0x7fb7fe1ef100, stack size: 4198144, maximum stack size: 8388608 2025.07.28 11:52:31.071200 [ 17207 ] {843f77fd-10c6-418e-aec8-086925dc7938} PushingToViews: Failed to push block to view test_5.v1 (4ae2feef-b6fa-47ac-b20c-744da14b2a0a), Stack size too large. Stack address: 0x7fb7fddf0000, frame address: 0x7fb7fe1ef100, stack size: 4198144, maximum stack size: 8388608 2025.07.28 11:52:31.075157 [ 17207 ] {843f77fd-10c6-418e-aec8-086925dc7938} PushingToViews: Failed to push block to view test_5.v2 (7c22a887-3ed3-40f1-a092-d92463e4b87b), Stack size too large. Stack address: 0x7fb7fddf0000, frame address: 0x7fb7fe1ef100, stack size: 4198144, maximum stack size: 8388608 2025.07.28 11:52:31.090879 [ 17207 ] {843f77fd-10c6-418e-aec8-086925dc7938} PushingToViews: Failed to push block to view test_5.v1 (4ae2feef-b6fa-47ac-b20c-744da14b2a0a), Stack size too large. Stack address: 0x7fb7fddf0000, frame address: 0x7fb7fe1ef100, stack size: 4198144, maximum stack size: 8388608 2025.07.28 11:52:31.092512 [ 17207 ] {843f77fd-10c6-418e-aec8-086925dc7938} PushingToViews: Failed to push block to view test_5.v2 (7c22a887-3ed3-40f1-a092-d92463e4b87b), Stack size too large. Stack address: 0x7fb7fddf0000, frame address: 0x7fb7fe1ef100, stack size: 4198144, maximum stack size: 8388608 2025.07.28 11:52:31.099612 [ 17207 ] {843f77fd-10c6-418e-aec8-086925dc7938} PushingToViews: Failed to push block to view test_5.v1 (4ae2feef-b6fa-47ac-b20c-744da14b2a0a), Stack size too large. Stack address: 0x7fb7fddf0000, frame address: 0x7fb7fe1ef100, stack size: 4198144, maximum stack size: 8388608 2025.07.28 11:52:31.101502 [ 17207 ] {843f77fd-10c6-418e-aec8-086925dc7938} PushingToViews: Failed to push block to view test_5.v2 (7c22a887-3ed3-40f1-a092-d92463e4b87b), Stack size too large. Stack address: 0x7fb7fddf0000, frame address: 0x7fb7fe1ef100, stack size: 4198144, maximum stack size: 8388608 2025.07.28 11:52:31.105027 [ 17207 ] {843f77fd-10c6-418e-aec8-086925dc7938} PushingToViews: Failed to push block to view test_5.v1 (4ae2feef-b6fa-47ac-b20c-744da14b2a0a), Stack size too large. Stack address: 0x7fb7fddf0000, frame address: 0x7fb7fe1ef100, stack size: 4198144, maximum stack size: 8388608 2025.07.28 11:52:31.106394 [ 17207 ] {843f77fd-10c6-418e-aec8-086925dc7938} PushingToViews: Failed to push block to view test_5.v2 (7c22a887-3ed3-40f1-a092-d92463e4b87b), Stack size too large. Stack address: 0x7fb7fddf0000, frame address: 0x7fb7fe1ef100, stack size: 4198144, maximum stack size: 8388608 2025.07.28 11:52:31.109352 [ 17207 ] {843f77fd-10c6-418e-aec8-086925dc7938} PushingToViews: Failed to push block to view test_5.v1 (4ae2feef-b6fa-47ac-b20c-744da14b2a0a), Stack size too large. Stack address: 0x7fb7fddf0000, frame address: 0x7fb7fe1ef100, stack size: 4198144, maximum stack size: 8388608 2025.07.28 11:52:31.110909 [ 17207 ] {843f77fd-10c6-418e-aec8-086925dc7938} PushingToViews: Failed to push block to view test_5.v2 (7c22a887-3ed3-40f1-a092-d92463e4b87b), Stack size too large. Stack address: 0x7fb7fddf0000, frame address: 0x7fb7fe1ef100, stack size: 4198144, maximum stack size: 8388608 2025.07.28 11:52:31.116527 [ 17207 ] {843f77fd-10c6-418e-aec8-086925dc7938} PushingToViews: Failed to push block to view test_5.v1 (4ae2feef-b6fa-47ac-b20c-744da14b2a0a), Stack size too large. Stack address: 0x7fb7fddf0000, frame address: 0x7fb7fe1ef100, stack size: 4198144, maximum stack size: 8388608 2025.07.28 11:52:31.119018 [ 17207 ] {843f77fd-10c6-418e-aec8-086925dc7938} PushingToViews: Failed to push block to view test_5.v2 (7c22a887-3ed3-40f1-a092-d92463e4b87b), Stack size too large. Stack address: 0x7fb7fddf0000, frame address: 0x7fb7fe1ef100, stack size: 4198144, maximum stack size: 8388608 2025.07.28 11:52:31.120537 [ 17207 ] {843f77fd-10c6-418e-aec8-086925dc7938} PushingToViews: Failed to push block to view test_5.v1 (4ae2feef-b6fa-47ac-b20c-744da14b2a0a), Stack size too large. Stack address: 0x7fb7fddf0000, frame address: 0x7fb7fe1ef100, stack size: 4198144, maximum stack size: 8388608 2025.07.28 11:52:31.122190 [ 17207 ] {843f77fd-10c6-418e-aec8-086925dc7938} PushingToViews: Failed to push block to view test_5.v2 (7c22a887-3ed3-40f1-a092-d92463e4b87b), Stack size too large. Stack address: 0x7fb7fddf0000, frame address: 0x7fb7fe1ef100, stack size: 4198144, maximum stack size: 8388608 2025.07.28 11:52:31.124142 [ 17207 ] {843f77fd-10c6-418e-aec8-086925dc7938} PushingToViews: Failed to push block to view test_5.v1 (4ae2feef-b6fa-47ac-b20c-744da14b2a0a), Stack size too large. Stack address: 0x7fb7fddf0000, frame address: 0x7fb7fe1ef100, stack size: 4198144, maximum stack size: 8388608 2025.07.28 11:52:31.128342 [ 17207 ] {843f77fd-10c6-418e-aec8-086925dc7938} PushingToViews: Failed to push block to view test_5.v2 (7c22a887-3ed3-40f1-a092-d92463e4b87b), Stack size too large. Stack address: 0x7fb7fddf0000, frame address: 0x7fb7fe1ef100, stack size: 4198144, maximum stack size: 8388608 2025.07.28 11:52:31.130870 [ 17207 ] {843f77fd-10c6-418e-aec8-086925dc7938} PushingToViews: Failed to push block to view test_5.v1 (4ae2feef-b6fa-47ac-b20c-744da14b2a0a), Stack size too large. Stack address: 0x7fb7fddf0000, frame address: 0x7fb7fe1ef100, stack size: 4198144, maximum stack size: 8388608 2025.07.28 11:52:31.141229 [ 17207 ] {843f77fd-10c6-418e-aec8-086925dc7938} PushingToViews: Failed to push block to view test_5.v2 (7c22a887-3ed3-40f1-a092-d92463e4b87b), Stack size too large. Stack address: 0x7fb7fddf0000, frame address: 0x7fb7fe1ef100, stack size: 4198144, maximum stack size: 8388608 2025.07.28 11:52:31.142840 [ 17207 ] {843f77fd-10c6-418e-aec8-086925dc7938} PushingToViews: Failed to push block to view test_5.v1 (4ae2feef-b6fa-47ac-b20c-744da14b2a0a), Stack size too large. Stack address: 0x7fb7fddf0000, frame address: 0x7fb7fe1ef100, stack size: 4198144, maximum stack size: 8388608 2025.07.28 11:52:31.145927 [ 17207 ] {843f77fd-10c6-418e-aec8-086925dc7938} PushingToViews: Failed to push block to view test_5.v2 (7c22a887-3ed3-40f1-a092-d92463e4b87b), Stack size too large. Stack address: 0x7fb7fddf0000, frame address: 0x7fb7fe1ef100, stack size: 4198144, maximum stack size: 8388608 2025.07.28 11:52:31.155797 [ 17207 ] {843f77fd-10c6-418e-aec8-086925dc7938} PushingToViews: Failed to push block to view test_5.v1 (4ae2feef-b6fa-47ac-b20c-744da14b2a0a), Stack size too large. Stack address: 0x7fb7fddf0000, frame address: 0x7fb7fe1ef100, stack size: 4198144, maximum stack size: 8388608 2025.07.28 11:52:31.157869 [ 17207 ] {843f77fd-10c6-418e-aec8-086925dc7938} PushingToViews: Failed to push block to view test_5.v2 (7c22a887-3ed3-40f1-a092-d92463e4b87b), Stack size too large. Stack address: 0x7fb7fddf0000, frame address: 0x7fb7fe1ef100, stack size: 4198144, maximum stack size: 8388608 2025.07.28 11:52:31.158952 [ 17207 ] {843f77fd-10c6-418e-aec8-086925dc7938} PushingToViews: Failed to push block to view test_5.v1 (4ae2feef-b6fa-47ac-b20c-744da14b2a0a), Stack size too large. Stack address: 0x7fb7fddf0000, frame address: 0x7fb7fe1ef100, stack size: 4198144, maximum stack size: 8388608 2025.07.28 11:52:31.160088 [ 17207 ] {843f77fd-10c6-418e-aec8-086925dc7938} PushingToViews: Failed to push block to view test_5.v2 (7c22a887-3ed3-40f1-a092-d92463e4b87b), Stack size too large. Stack address: 0x7fb7fddf0000, frame address: 0x7fb7fe1ef100, stack size: 4198144, maximum stack size: 8388608 2025.07.28 11:52:31.161967 [ 17207 ] {843f77fd-10c6-418e-aec8-086925dc7938} PushingToViews: Failed to push block to view test_5.v1 (4ae2feef-b6fa-47ac-b20c-744da14b2a0a), Stack size too large. Stack address: 0x7fb7fddf0000, frame address: 0x7fb7fe1ef100, stack size: 4198144, maximum stack size: 8388608 2025.07.28 11:52:31.163413 [ 17207 ] {843f77fd-10c6-418e-aec8-086925dc7938} PushingToViews: Failed to push block to view test_5.v2 (7c22a887-3ed3-40f1-a092-d92463e4b87b), Stack size too large. Stack address: 0x7fb7fddf0000, frame address: 0x7fb7fe1ef100, stack size: 4198144, maximum stack size: 8388608 2025.07.28 11:52:31.164503 [ 17207 ] {843f77fd-10c6-418e-aec8-086925dc7938} PushingToViews: Failed to push block to view test_5.v1 (4ae2feef-b6fa-47ac-b20c-744da14b2a0a), Stack size too large. Stack address: 0x7fb7fddf0000, frame address: 0x7fb7fe1ef100, stack size: 4198144, maximum stack size: 8388608 2025.07.28 11:52:31.165483 [ 17207 ] {843f77fd-10c6-418e-aec8-086925dc7938} PushingToViews: Failed to push block to view test_5.v2 (7c22a887-3ed3-40f1-a092-d92463e4b87b), Stack size too large. Stack address: 0x7fb7fddf0000, frame address: 0x7fb7fe1ef100, stack size: 4198144, maximum stack size: 8388608 2025.07.28 11:52:31.167617 [ 17207 ] {843f77fd-10c6-418e-aec8-086925dc7938} PushingToViews: Failed to push block to view test_5.v1 (4ae2feef-b6fa-47ac-b20c-744da14b2a0a), Stack size too large. Stack address: 0x7fb7fddf0000, frame address: 0x7fb7fe1ef100, stack size: 4198144, maximum stack size: 8388608 2025.07.28 11:52:31.232317 [ 17207 ] {843f77fd-10c6-418e-aec8-086925dc7938} PushingToViews: Failed to push block to view test_5.v2 (7c22a887-3ed3-40f1-a092-d92463e4b87b), Stack size too large. Stack address: 0x7fb7fddf0000, frame address: 0x7fb7fe1ef100, stack size: 4198144, maximum stack size: 8388608 2025.07.28 11:52:31.234424 [ 17207 ] {843f77fd-10c6-418e-aec8-086925dc7938} PushingToViews: Failed to push block to view test_5.v1 (4ae2feef-b6fa-47ac-b20c-744da14b2a0a), Stack size too large. Stack address: 0x7fb7fddf0000, frame address: 0x7fb7fe1ef100, stack size: 4198144, maximum stack size: 8388608 2025.07.28 11:52:31.266385 [ 17207 ] {843f77fd-10c6-418e-aec8-086925dc7938} PushingToViews: Failed to push block to view test_5.v2 (7c22a887-3ed3-40f1-a092-d92463e4b87b), Stack size too large. Stack address: 0x7fb7fddf0000, frame address: 0x7fb7fe1ef100, stack size: 4198144, maximum stack size: 8388608 2025.07.28 11:52:31.267618 [ 17207 ] {843f77fd-10c6-418e-aec8-086925dc7938} PushingToViews: Failed to push block to view test_5.v1 (4ae2feef-b6fa-47ac-b20c-744da14b2a0a), Stack size too large. Stack address: 0x7fb7fddf0000, frame address: 0x7fb7fe1ef100, stack size: 4198144, maximum stack size: 8388608 2025.07.28 11:52:31.274505 [ 17207 ] {843f77fd-10c6-418e-aec8-086925dc7938} PushingToViews: Failed to push block to view test_5.v2 (7c22a887-3ed3-40f1-a092-d92463e4b87b), Stack size too large. Stack address: 0x7fb7fddf0000, frame address: 0x7fb7fe1ef100, stack size: 4198144, maximum stack size: 8388608 2025.07.28 11:52:31.275875 [ 17207 ] {843f77fd-10c6-418e-aec8-086925dc7938} PushingToViews: Failed to push block to view test_5.v1 (4ae2feef-b6fa-47ac-b20c-744da14b2a0a), Stack size too large. Stack address: 0x7fb7fddf0000, frame address: 0x7fb7fe1ef100, stack size: 4198144, maximum stack size: 8388608 2025.07.28 11:52:31.277072 [ 17207 ] {843f77fd-10c6-418e-aec8-086925dc7938} PushingToViews: Failed to push block to view test_5.v2 (7c22a887-3ed3-40f1-a092-d92463e4b87b), Stack size too large. Stack address: 0x7fb7fddf0000, frame address: 0x7fb7fe1ef100, stack size: 4198144, maximum stack size: 8388608 2025.07.28 11:52:31.279491 [ 17207 ] {843f77fd-10c6-418e-aec8-086925dc7938} PushingToViews: Failed to push block to view test_5.v1 (4ae2feef-b6fa-47ac-b20c-744da14b2a0a), Stack size too large. Stack address: 0x7fb7fddf0000, frame address: 0x7fb7fe1ef100, stack size: 4198144, maximum stack size: 8388608 2025.07.28 11:52:31.283458 [ 17207 ] {843f77fd-10c6-418e-aec8-086925dc7938} PushingToViews: Failed to push block to view test_5.v2 (7c22a887-3ed3-40f1-a092-d92463e4b87b), Stack size too large. Stack address: 0x7fb7fddf0000, frame address: 0x7fb7fe1ef100, stack size: 4198144, maximum stack size: 8388608 2025.07.28 11:52:31.285145 [ 17207 ] {843f77fd-10c6-418e-aec8-086925dc7938} PushingToViews: Failed to push block to view test_5.v1 (4ae2feef-b6fa-47ac-b20c-744da14b2a0a), Stack size too large. Stack address: 0x7fb7fddf0000, frame address: 0x7fb7fe1ef100, stack size: 4198144, maximum stack size: 8388608 2025.07.28 11:52:31.286549 [ 17207 ] {843f77fd-10c6-418e-aec8-086925dc7938} PushingToViews: Failed to push block to view test_5.v2 (7c22a887-3ed3-40f1-a092-d92463e4b87b), Stack size too large. Stack address: 0x7fb7fddf0000, frame address: 0x7fb7fe1ef100, stack size: 4198144, maximum stack size: 8388608 2025.07.28 11:52:31.290037 [ 17207 ] {843f77fd-10c6-418e-aec8-086925dc7938} PushingToViews: Failed to push block to view test_5.v1 (4ae2feef-b6fa-47ac-b20c-744da14b2a0a), Stack size too large. Stack address: 0x7fb7fddf0000, frame address: 0x7fb7fe1ef100, stack size: 4198144, maximum stack size: 8388608 2025.07.28 11:52:31.294704 [ 17207 ] {843f77fd-10c6-418e-aec8-086925dc7938} PushingToViews: Failed to push block to view test_5.v2 (7c22a887-3ed3-40f1-a092-d92463e4b87b), Stack size too large. Stack address: 0x7fb7fddf0000, frame address: 0x7fb7fe1ef100, stack size: 4198144, maximum stack size: 8388608 2025.07.28 11:52:31.296435 [ 17207 ] {843f77fd-10c6-418e-aec8-086925dc7938} PushingToViews: Failed to push block to view test_5.v1 (4ae2feef-b6fa-47ac-b20c-744da14b2a0a), Stack size too large. Stack address: 0x7fb7fddf0000, frame address: 0x7fb7fe1ef100, stack size: 4198144, maximum stack size: 8388608 2025.07.28 11:52:31.298479 [ 17207 ] {843f77fd-10c6-418e-aec8-086925dc7938} PushingToViews: Failed to push block to view test_5.v2 (7c22a887-3ed3-40f1-a092-d92463e4b87b), Stack size too large. Stack address: 0x7fb7fddf0000, frame address: 0x7fb7fe1ef100, stack size: 4198144, maximum stack size: 8388608 2025.07.28 11:52:31.299669 [ 17207 ] {843f77fd-10c6-418e-aec8-086925dc7938} PushingToViews: Failed to push block to view test_5.v1 (4ae2feef-b6fa-47ac-b20c-744da14b2a0a), Stack size too large. Stack address: 0x7fb7fddf0000, frame address: 0x7fb7fe1ef100, stack size: 4198144, maximum stack size: 8388608 2025.07.28 11:52:31.300663 [ 17207 ] {843f77fd-10c6-418e-aec8-086925dc7938} PushingToViews: Failed to push block to view test_5.v2 (7c22a887-3ed3-40f1-a092-d92463e4b87b), Stack size too large. Stack address: 0x7fb7fddf0000, frame address: 0x7fb7fe1ef100, stack size: 4198144, maximum stack size: 8388608 2025.07.28 11:52:31.303139 [ 17207 ] {843f77fd-10c6-418e-aec8-086925dc7938} PushingToViews: Failed to push block to view test_5.v1 (4ae2feef-b6fa-47ac-b20c-744da14b2a0a), Stack size too large. Stack address: 0x7fb7fddf0000, frame address: 0x7fb7fe1ef100, stack size: 4198144, maximum stack size: 8388608 2025.07.28 11:52:31.304475 [ 17207 ] {843f77fd-10c6-418e-aec8-086925dc7938} PushingToViews: Failed to push block to view test_5.v2 (7c22a887-3ed3-40f1-a092-d92463e4b87b), Stack size too large. Stack address: 0x7fb7fddf0000, frame address: 0x7fb7fe1ef100, stack size: 4198144, maximum stack size: 8388608 2025.07.28 11:52:31.305428 [ 17207 ] {843f77fd-10c6-418e-aec8-086925dc7938} PushingToViews: Failed to push block to view test_5.v1 (4ae2feef-b6fa-47ac-b20c-744da14b2a0a), Stack size too large. Stack address: 0x7fb7fddf0000, frame address: 0x7fb7fe1ef100, stack size: 4198144, maximum stack size: 8388608 2025.07.28 11:52:31.306502 [ 17207 ] {843f77fd-10c6-418e-aec8-086925dc7938} PushingToViews: Failed to push block to view test_5.v2 (7c22a887-3ed3-40f1-a092-d92463e4b87b), Stack size too large. Stack address: 0x7fb7fddf0000, frame address: 0x7fb7fe1ef100, stack size: 4198144, maximum stack size: 8388608 2025.07.28 11:52:31.308496 [ 17207 ] {843f77fd-10c6-418e-aec8-086925dc7938} PushingToViews: Failed to push block to view test_5.v1 (4ae2feef-b6fa-47ac-b20c-744da14b2a0a), Stack size too large. Stack address: 0x7fb7fddf0000, frame address: 0x7fb7fe1ef100, stack size: 4198144, maximum stack size: 8388608 2025.07.28 11:52:31.309526 [ 17207 ] {843f77fd-10c6-418e-aec8-086925dc7938} PushingToViews: Failed to push block to view test_5.v2 (7c22a887-3ed3-40f1-a092-d92463e4b87b), Stack size too large. Stack address: 0x7fb7fddf0000, frame address: 0x7fb7fe1ef100, stack size: 4198144, maximum stack size: 8388608 2025.07.28 11:52:31.310758 [ 17207 ] {843f77fd-10c6-418e-aec8-086925dc7938} PushingToViews: Failed to push block to view test_5.v1 (4ae2feef-b6fa-47ac-b20c-744da14b2a0a), Stack size too large. Stack address: 0x7fb7fddf0000, frame address: 0x7fb7fe1ef100, stack size: 4198144, maximum stack size: 8388608 2025.07.28 11:52:31.313453 [ 17207 ] {843f77fd-10c6-418e-aec8-086925dc7938} PushingToViews: Failed to push block to view test_5.v2 (7c22a887-3ed3-40f1-a092-d92463e4b87b), Stack size too large. Stack address: 0x7fb7fddf0000, frame address: 0x7fb7fe1ef100, stack size: 4198144, maximum stack size: 8388608 2025.07.28 11:52:31.314608 [ 17207 ] {843f77fd-10c6-418e-aec8-086925dc7938} PushingToViews: Failed to push block to view test_5.v1 (4ae2feef-b6fa-47ac-b20c-744da14b2a0a), Stack size too large. Stack address: 0x7fb7fddf0000, frame address: 0x7fb7fe1ef100, stack size: 4198144, maximum stack size: 8388608 2025.07.28 11:52:31.315658 [ 17207 ] {843f77fd-10c6-418e-aec8-086925dc7938} PushingToViews: Failed to push block to view test_5.v2 (7c22a887-3ed3-40f1-a092-d92463e4b87b), Stack size too large. Stack address: 0x7fb7fddf0000, frame address: 0x7fb7fe1ef100, stack size: 4198144, maximum stack size: 8388608 2025.07.28 11:52:31.335872 [ 17207 ] {843f77fd-10c6-418e-aec8-086925dc7938} PushingToViews: Failed to push block to view test_5.v1 (4ae2feef-b6fa-47ac-b20c-744da14b2a0a), Stack size too large. Stack address: 0x7fb7fddf0000, frame address: 0x7fb7fe1ef100, stack size: 4198144, maximum stack size: 8388608 2025.07.28 11:52:31.337027 [ 17207 ] {843f77fd-10c6-418e-aec8-086925dc7938} PushingToViews: Failed to push block to view test_5.v2 (7c22a887-3ed3-40f1-a092-d92463e4b87b), Stack size too large. Stack address: 0x7fb7fddf0000, frame address: 0x7fb7fe1ef100, stack size: 4198144, maximum stack size: 8388608 2025.07.28 11:52:31.338412 [ 17207 ] {843f77fd-10c6-418e-aec8-086925dc7938} PushingToViews: Failed to push block to view test_5.v1 (4ae2feef-b6fa-47ac-b20c-744da14b2a0a), Stack size too large. Stack address: 0x7fb7fddf0000, frame address: 0x7fb7fe1ef100, stack size: 4198144, maximum stack size: 8388608 2025.07.28 11:52:31.340687 [ 17207 ] {843f77fd-10c6-418e-aec8-086925dc7938} PushingToViews: Failed to push block to view test_5.v2 (7c22a887-3ed3-40f1-a092-d92463e4b87b), Stack size too large. Stack address: 0x7fb7fddf0000, frame address: 0x7fb7fe1ef100, stack size: 4198144, maximum stack size: 8388608 2025.07.28 11:52:31.343242 [ 17207 ] {843f77fd-10c6-418e-aec8-086925dc7938} PushingToViews: Failed to push block to view test_5.v1 (4ae2feef-b6fa-47ac-b20c-744da14b2a0a), Stack size too large. Stack address: 0x7fb7fddf0000, frame address: 0x7fb7fe1ef100, stack size: 4198144, maximum stack size: 8388608 2025.07.28 11:52:31.344589 [ 17207 ] {843f77fd-10c6-418e-aec8-086925dc7938} PushingToViews: Failed to push block to view test_5.v2 (7c22a887-3ed3-40f1-a092-d92463e4b87b), Stack size too large. Stack address: 0x7fb7fddf0000, frame address: 0x7fb7fe1ef100, stack size: 4198144, maximum stack size: 8388608 2025.07.28 11:52:31.345916 [ 17207 ] {843f77fd-10c6-418e-aec8-086925dc7938} PushingToViews: Failed to push block to view test_5.v1 (4ae2feef-b6fa-47ac-b20c-744da14b2a0a), Stack size too large. Stack address: 0x7fb7fddf0000, frame address: 0x7fb7fe1ef100, stack size: 4198144, maximum stack size: 8388608 2025.07.28 11:52:31.351927 [ 17207 ] {843f77fd-10c6-418e-aec8-086925dc7938} PushingToViews: Failed to push block to view test_5.v2 (7c22a887-3ed3-40f1-a092-d92463e4b87b), Stack size too large. Stack address: 0x7fb7fddf0000, frame address: 0x7fb7fe1ef100, stack size: 4198144, maximum stack size: 8388608 2025.07.28 11:52:31.353055 [ 17207 ] {843f77fd-10c6-418e-aec8-086925dc7938} PushingToViews: Failed to push block to view test_5.v1 (4ae2feef-b6fa-47ac-b20c-744da14b2a0a), Stack size too large. Stack address: 0x7fb7fddf0000, frame address: 0x7fb7fe1ef100, stack size: 4198144, maximum stack size: 8388608 2025.07.28 11:52:31.357347 [ 17207 ] {843f77fd-10c6-418e-aec8-086925dc7938} PushingToViews: Failed to push block to view test_5.v2 (7c22a887-3ed3-40f1-a092-d92463e4b87b), Stack size too large. Stack address: 0x7fb7fddf0000, frame address: 0x7fb7fe1ef100, stack size: 4198144, maximum stack size: 8388608 2025.07.28 11:52:31.359064 [ 17207 ] {843f77fd-10c6-418e-aec8-086925dc7938} PushingToViews: Failed to push block to view test_5.v1 (4ae2feef-b6fa-47ac-b20c-744da14b2a0a), Stack size too large. Stack address: 0x7fb7fddf0000, frame address: 0x7fb7fe1ef100, stack size: 4198144, maximum stack size: 8388608 2025.07.28 11:52:31.364490 [ 17207 ] {843f77fd-10c6-418e-aec8-086925dc7938} PushingToViews: Failed to push block to view test_5.v2 (7c22a887-3ed3-40f1-a092-d92463e4b87b), Stack size too large. Stack address: 0x7fb7fddf0000, frame address: 0x7fb7fe1ef100, stack size: 4198144, maximum stack size: 8388608 2025.07.28 11:52:31.365411 [ 17207 ] {843f77fd-10c6-418e-aec8-086925dc7938} PushingToViews: Failed to push block to view test_5.v1 (4ae2feef-b6fa-47ac-b20c-744da14b2a0a), Stack size too large. Stack address: 0x7fb7fddf0000, frame address: 0x7fb7fe1ef100, stack size: 4198144, maximum stack size: 8388608 2025.07.28 11:52:31.368851 [ 17207 ] {843f77fd-10c6-418e-aec8-086925dc7938} PushingToViews: Failed to push block to view test_5.v2 (7c22a887-3ed3-40f1-a092-d92463e4b87b), Stack size too large. Stack address: 0x7fb7fddf0000, frame address: 0x7fb7fe1ef100, stack size: 4198144, maximum stack size: 8388608 2025.07.28 11:52:31.375813 [ 17207 ] {843f77fd-10c6-418e-aec8-086925dc7938} PushingToViews: Failed to push block to view test_5.v1 (4ae2feef-b6fa-47ac-b20c-744da14b2a0a), Stack size too large. Stack address: 0x7fb7fddf0000, frame address: 0x7fb7fe1ef100, stack size: 4198144, maximum stack size: 8388608 2025.07.28 11:52:31.376949 [ 17207 ] {843f77fd-10c6-418e-aec8-086925dc7938} PushingToViews: Failed to push block to view test_5.v2 (7c22a887-3ed3-40f1-a092-d92463e4b87b), Stack size too large. Stack address: 0x7fb7fddf0000, frame address: 0x7fb7fe1ef100, stack size: 4198144, maximum stack size: 8388608 2025.07.28 11:52:31.378267 [ 17207 ] {843f77fd-10c6-418e-aec8-086925dc7938} PushingToViews: Failed to push block to view test_5.v1 (4ae2feef-b6fa-47ac-b20c-744da14b2a0a), Stack size too large. Stack address: 0x7fb7fddf0000, frame address: 0x7fb7fe1ef100, stack size: 4198144, maximum stack size: 8388608 2025.07.28 11:52:31.380862 [ 17207 ] {843f77fd-10c6-418e-aec8-086925dc7938} PushingToViews: Failed to push block to view test_5.v2 (7c22a887-3ed3-40f1-a092-d92463e4b87b), Stack size too large. Stack address: 0x7fb7fddf0000, frame address: 0x7fb7fe1ef100, stack size: 4198144, maximum stack size: 8388608 2025.07.28 11:52:31.381991 [ 17207 ] {843f77fd-10c6-418e-aec8-086925dc7938} PushingToViews: Failed to push block to view test_5.v1 (4ae2feef-b6fa-47ac-b20c-744da14b2a0a), Stack size too large. Stack address: 0x7fb7fddf0000, frame address: 0x7fb7fe1ef100, stack size: 4198144, maximum stack size: 8388608 2025.07.28 11:52:31.384097 [ 17207 ] {843f77fd-10c6-418e-aec8-086925dc7938} PushingToViews: Failed to push block to view test_5.v2 (7c22a887-3ed3-40f1-a092-d92463e4b87b), Stack size too large. Stack address: 0x7fb7fddf0000, frame address: 0x7fb7fe1ef100, stack size: 4198144, maximum stack size: 8388608 2025.07.28 11:52:31.385673 [ 17207 ] {843f77fd-10c6-418e-aec8-086925dc7938} PushingToViews: Failed to push block to view test_5.v1 (4ae2feef-b6fa-47ac-b20c-744da14b2a0a), Stack size too large. Stack address: 0x7fb7fddf0000, frame address: 0x7fb7fe1ef100, stack size: 4198144, maximum stack size: 8388608 2025.07.28 11:52:31.386655 [ 17207 ] {843f77fd-10c6-418e-aec8-086925dc7938} PushingToViews: Failed to push block to view test_5.v2 (7c22a887-3ed3-40f1-a092-d92463e4b87b), Stack size too large. Stack address: 0x7fb7fddf0000, frame address: 0x7fb7fe1ef100, stack size: 4198144, maximum stack size: 8388608 2025.07.28 11:52:31.392644 [ 17207 ] {843f77fd-10c6-418e-aec8-086925dc7938} PushingToViews: Failed to push block to view test_5.v1 (4ae2feef-b6fa-47ac-b20c-744da14b2a0a), Stack size too large. Stack address: 0x7fb7fddf0000, frame address: 0x7fb7fe1ef100, stack size: 4198144, maximum stack size: 8388608 2025.07.28 11:52:31.398298 [ 17207 ] {843f77fd-10c6-418e-aec8-086925dc7938} PushingToViews: Failed to push block to view test_5.v2 (7c22a887-3ed3-40f1-a092-d92463e4b87b), Stack size too large. Stack address: 0x7fb7fddf0000, frame address: 0x7fb7fe1ef100, stack size: 4198144, maximum stack size: 8388608 2025.07.28 11:52:31.404565 [ 17207 ] {843f77fd-10c6-418e-aec8-086925dc7938} PushingToViews: Failed to push block to view test_5.v1 (4ae2feef-b6fa-47ac-b20c-744da14b2a0a), Stack size too large. Stack address: 0x7fb7fddf0000, frame address: 0x7fb7fe1ef100, stack size: 4198144, maximum stack size: 8388608 2025.07.28 11:52:31.406505 [ 17207 ] {843f77fd-10c6-418e-aec8-086925dc7938} PushingToViews: Failed to push block to view test_5.v2 (7c22a887-3ed3-40f1-a092-d92463e4b87b), Stack size too large. Stack address: 0x7fb7fddf0000, frame address: 0x7fb7fe1ef100, stack size: 4198144, maximum stack size: 8388608 2025.07.28 11:52:31.408220 [ 17207 ] {843f77fd-10c6-418e-aec8-086925dc7938} PushingToViews: Failed to push block to view test_5.v1 (4ae2feef-b6fa-47ac-b20c-744da14b2a0a), Stack size too large. Stack address: 0x7fb7fddf0000, frame address: 0x7fb7fe1ef100, stack size: 4198144, maximum stack size: 8388608 2025.07.28 11:52:31.410198 [ 17207 ] {843f77fd-10c6-418e-aec8-086925dc7938} PushingToViews: Failed to push block to view test_5.v2 (7c22a887-3ed3-40f1-a092-d92463e4b87b), Stack size too large. Stack address: 0x7fb7fddf0000, frame address: 0x7fb7fe1ef100, stack size: 4198144, maximum stack size: 8388608 2025.07.28 11:52:31.416151 [ 17207 ] {843f77fd-10c6-418e-aec8-086925dc7938} PushingToViews: Failed to push block to view test_5.v1 (4ae2feef-b6fa-47ac-b20c-744da14b2a0a), Stack size too large. Stack address: 0x7fb7fddf0000, frame address: 0x7fb7fe1ef100, stack size: 4198144, maximum stack size: 8388608 2025.07.28 11:52:31.418925 [ 17207 ] {843f77fd-10c6-418e-aec8-086925dc7938} PushingToViews: Failed to push block to view test_5.v2 (7c22a887-3ed3-40f1-a092-d92463e4b87b), Stack size too large. Stack address: 0x7fb7fddf0000, frame address: 0x7fb7fe1ef100, stack size: 4198144, maximum stack size: 8388608 2025.07.28 11:52:31.421031 [ 17207 ] {843f77fd-10c6-418e-aec8-086925dc7938} PushingToViews: Failed to push block to view test_5.v1 (4ae2feef-b6fa-47ac-b20c-744da14b2a0a), Stack size too large. Stack address: 0x7fb7fddf0000, frame address: 0x7fb7fe1ef100, stack size: 4198144, maximum stack size: 8388608 2025.07.28 11:52:31.423044 [ 17207 ] {843f77fd-10c6-418e-aec8-086925dc7938} PushingToViews: Failed to push block to view test_5.v2 (7c22a887-3ed3-40f1-a092-d92463e4b87b), Stack size too large. Stack address: 0x7fb7fddf0000, frame address: 0x7fb7fe1ef100, stack size: 4198144, maximum stack size: 8388608 2025.07.28 11:52:31.426011 [ 17207 ] {843f77fd-10c6-418e-aec8-086925dc7938} PushingToViews: Failed to push block to view test_5.v1 (4ae2feef-b6fa-47ac-b20c-744da14b2a0a), Stack size too large. Stack address: 0x7fb7fddf0000, frame address: 0x7fb7fe1ef100, stack size: 4198144, maximum stack size: 8388608 2025.07.28 11:52:31.435865 [ 17207 ] {843f77fd-10c6-418e-aec8-086925dc7938} PushingToViews: Failed to push block to view test_5.v2 (7c22a887-3ed3-40f1-a092-d92463e4b87b), Stack size too large. Stack address: 0x7fb7fddf0000, frame address: 0x7fb7fe1ef100, stack size: 4198144, maximum stack size: 8388608 2025.07.28 11:52:31.438139 [ 17207 ] {843f77fd-10c6-418e-aec8-086925dc7938} PushingToViews: Failed to push block to view test_5.v1 (4ae2feef-b6fa-47ac-b20c-744da14b2a0a), Stack size too large. Stack address: 0x7fb7fddf0000, frame address: 0x7fb7fe1ef100, stack size: 4198144, maximum stack size: 8388608 2025.07.28 11:52:31.441518 [ 17207 ] {843f77fd-10c6-418e-aec8-086925dc7938} PushingToViews: Failed to push block to view test_5.v2 (7c22a887-3ed3-40f1-a092-d92463e4b87b), Stack size too large. Stack address: 0x7fb7fddf0000, frame address: 0x7fb7fe1ef100, stack size: 4198144, maximum stack size: 8388608 2025.07.28 11:52:31.452524 [ 17207 ] {843f77fd-10c6-418e-aec8-086925dc7938} PushingToViews: Failed to push block to view test_5.v1 (4ae2feef-b6fa-47ac-b20c-744da14b2a0a), Stack size too large. Stack address: 0x7fb7fddf0000, frame address: 0x7fb7fe1ef100, stack size: 4198144, maximum stack size: 8388608 2025.07.28 11:52:31.454501 [ 17207 ] {843f77fd-10c6-418e-aec8-086925dc7938} PushingToViews: Failed to push block to view test_5.v2 (7c22a887-3ed3-40f1-a092-d92463e4b87b), Stack size too large. Stack address: 0x7fb7fddf0000, frame address: 0x7fb7fe1ef100, stack size: 4198144, maximum stack size: 8388608 2025.07.28 11:52:31.457901 [ 17207 ] {843f77fd-10c6-418e-aec8-086925dc7938} PushingToViews: Failed to push block to view test_5.v1 (4ae2feef-b6fa-47ac-b20c-744da14b2a0a), Stack size too large. Stack address: 0x7fb7fddf0000, frame address: 0x7fb7fe1ef100, stack size: 4198144, maximum stack size: 8388608 2025.07.28 11:52:31.460516 [ 17207 ] {843f77fd-10c6-418e-aec8-086925dc7938} PushingToViews: Failed to push block to view test_5.v2 (7c22a887-3ed3-40f1-a092-d92463e4b87b), Stack size too large. Stack address: 0x7fb7fddf0000, frame address: 0x7fb7fe1ef100, stack size: 4198144, maximum stack size: 8388608 2025.07.28 11:52:31.461182 [ 3977 ] {} test_13.rmt2 (7f9b740d-015c-470e-8cc6-8ba33be0dc63): auto DB::StorageReplicatedMergeTree::processQueueEntry(ReplicatedMergeTreeQueue::SelectedEntryPtr)::(anonymous class)::operator()(LogEntryPtr &) const: Code: 86. DB::HTTPException: Received error from remote server http://146b4357c08d:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Ftest%2F01165%2Ftest_13%2Frmt%2Freplicas%2F1&part=20250728_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.6.10636.altinitytest (altinity build)) '. (RECEIVED_ERROR_FROM_REMOTE_IO_SERVER), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.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 const&, int&&, String const&, unsigned long&&, String const&) @ 0x000000000feda8d9 4. /build/src/IO/HTTPCommon.cpp:104: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x000000000feda6e2 5. /build/src/IO/HTTPCommon.cpp:93: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x000000000feda537 6. /build/src/IO/ReadWriteBufferFromHTTP.cpp:277: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x000000001184a4c4 7. /build/src/IO/ReadWriteBufferFromHTTP.cpp:285: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x000000001184a615 8. /build/src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x000000001184ae59 9. /build/src/IO/ReadWriteBufferFromHTTP.cpp:472: void std::__function::__policy_invoker::__call_impl[abi:se190107]>(std::__function::__policy_storage const*) @ 0x000000001184cedd 10. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001184858b 11. /build/src/IO/ReadWriteBufferFromHTTP.cpp:465: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x000000001184bf0b 12. /build/src/IO/ReadBuffer.h:60: DB::ReadBuffer::next() @ 0x000000000a148c7b 13. /build/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) @ 0x0000000011849fb2 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]>&)>&, 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&) @ 0x0000000011841980 15. /build/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) @ 0x000000001621208e 16. /build/src/Storages/StorageReplicatedMergeTree.cpp:5228: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl[abi:se190107] const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000015f9a5fe 17. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000015ed8bfd 18. /build/src/Storages/StorageReplicatedMergeTree.cpp:2514: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x0000000015ec9aab 19. /build/src/Storages/StorageReplicatedMergeTree.cpp:2349: DB::StorageReplicatedMergeTree::executeLogEntry(DB::ReplicatedMergeTreeLogEntry&) @ 0x0000000015eba91b 20. /build/src/Storages/StorageReplicatedMergeTree.cpp:3876: bool std::__function::__policy_invoker&)>::__call_impl[abi:se190107])::$_1, bool (std::shared_ptr&)>>(std::__function::__policy_storage const*, std::shared_ptr&) @ 0x0000000015f9837e 21. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000165d6fc3 22. /build/src/Storages/StorageReplicatedMergeTree.cpp:3872: DB::StorageReplicatedMergeTree::processQueueEntry(std::shared_ptr) @ 0x0000000015efc18a 23. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001624c1b2 24. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000162f9c70 25. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x00000000162fa55a 26. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc6653 27. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000000fccc4c3 28. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc3d92 29. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fcca080 30. ? @ 0x00007fbc6213eac3 31. ? @ 0x00007fbc621d0850 (version 25.3.6.10636.altinitytest (altinity build)) 2025.07.28 11:52:31.461823 [ 17207 ] {843f77fd-10c6-418e-aec8-086925dc7938} PushingToViews: Failed to push block to view test_5.v1 (4ae2feef-b6fa-47ac-b20c-744da14b2a0a), Stack size too large. Stack address: 0x7fb7fddf0000, frame address: 0x7fb7fe1ef100, stack size: 4198144, maximum stack size: 8388608 2025.07.28 11:52:31.467124 [ 17207 ] {843f77fd-10c6-418e-aec8-086925dc7938} PushingToViews: Failed to push block to view test_5.v2 (7c22a887-3ed3-40f1-a092-d92463e4b87b), Stack size too large. Stack address: 0x7fb7fddf0000, frame address: 0x7fb7fe1ef100, stack size: 4198144, maximum stack size: 8388608 2025.07.28 11:52:31.471040 [ 17207 ] {843f77fd-10c6-418e-aec8-086925dc7938} PushingToViews: Failed to push block to view test_5.v1 (4ae2feef-b6fa-47ac-b20c-744da14b2a0a), Stack size too large. Stack address: 0x7fb7fddf0000, frame address: 0x7fb7fe1ef100, stack size: 4198144, maximum stack size: 8388608 2025.07.28 11:52:31.472666 [ 17207 ] {843f77fd-10c6-418e-aec8-086925dc7938} PushingToViews: Failed to push block to view test_5.v2 (7c22a887-3ed3-40f1-a092-d92463e4b87b), Stack size too large. Stack address: 0x7fb7fddf0000, frame address: 0x7fb7fe1ef100, stack size: 4198144, maximum stack size: 8388608 2025.07.28 11:52:31.477775 [ 17207 ] {843f77fd-10c6-418e-aec8-086925dc7938} PushingToViews: Failed to push block to view test_5.v1 (4ae2feef-b6fa-47ac-b20c-744da14b2a0a), Stack size too large. Stack address: 0x7fb7fddf0000, frame address: 0x7fb7fe1ef100, stack size: 4198144, maximum stack size: 8388608 2025.07.28 11:52:31.488123 [ 17207 ] {843f77fd-10c6-418e-aec8-086925dc7938} PushingToViews: Failed to push block to view test_5.v2 (7c22a887-3ed3-40f1-a092-d92463e4b87b), Stack size too large. Stack address: 0x7fb7fddf0000, frame address: 0x7fb7fe1ef100, stack size: 4198144, maximum stack size: 8388608 2025.07.28 11:52:31.496081 [ 17207 ] {843f77fd-10c6-418e-aec8-086925dc7938} PushingToViews: Failed to push block to view test_5.v1 (4ae2feef-b6fa-47ac-b20c-744da14b2a0a), Stack size too large. Stack address: 0x7fb7fddf0000, frame address: 0x7fb7fe1ef100, stack size: 4198144, maximum stack size: 8388608 2025.07.28 11:52:31.500163 [ 17207 ] {843f77fd-10c6-418e-aec8-086925dc7938} PushingToViews: Failed to push block to view test_5.v2 (7c22a887-3ed3-40f1-a092-d92463e4b87b), Stack size too large. Stack address: 0x7fb7fddf0000, frame address: 0x7fb7fe1ef100, stack size: 4198144, maximum stack size: 8388608 2025.07.28 11:52:31.508274 [ 17207 ] {843f77fd-10c6-418e-aec8-086925dc7938} PushingToViews: Failed to push block to view test_5.v1 (4ae2feef-b6fa-47ac-b20c-744da14b2a0a), Stack size too large. Stack address: 0x7fb7fddf0000, frame address: 0x7fb7fe1ef100, stack size: 4198144, maximum stack size: 8388608 2025.07.28 11:52:31.509990 [ 17207 ] {843f77fd-10c6-418e-aec8-086925dc7938} PushingToViews: Failed to push block to view test_5.v2 (7c22a887-3ed3-40f1-a092-d92463e4b87b), Stack size too large. Stack address: 0x7fb7fddf0000, frame address: 0x7fb7fe1ef100, stack size: 4198144, maximum stack size: 8388608 2025.07.28 11:52:31.770654 [ 17207 ] {843f77fd-10c6-418e-aec8-086925dc7938} executeQuery: Code: 306. DB::Exception: Stack size too large. Stack address: 0x7fb7fddf0000, frame address: 0x7fb7fe1ef100, stack size: 4198144, maximum stack size: 8388608. (TOO_DEEP_RECURSION) (version 25.3.6.10636.altinitytest (altinity build)) (from [::1]:56256) (comment: 01527_materialized_view_stack_overflow.sql) (query 14, line 20) (in query: INSERT INTO t1 VALUES ), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, void*&, void const*&, unsigned long&, unsigned long&) @ 0x000000000fc5a24b 4. /build/src/Common/checkStackSize.cpp:151: checkStackSize() @ 0x000000000fc5a14c 5. /build/src/Interpreters/DatabaseCatalog.cpp:338: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x00000000144f0432 6. /build/src/Interpreters/DatabaseCatalog.cpp:984: DB::DatabaseCatalog::tryGetTable(DB::StorageID const&, std::shared_ptr) const @ 0x00000000144f6b77 7. /build/src/Analyzer/Resolve/IdentifierResolver.cpp:177: DB::IdentifierResolver::tryResolveTableIdentifierFromDatabaseCatalog(DB::Identifier const&, std::shared_ptr const&) @ 0x00000000142b9931 8. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:1550: DB::QueryAnalyzer::tryResolveIdentifier(DB::IdentifierLookup const&, DB::IdentifierResolveScope&, DB::IdentifierResolveContext) @ 0x00000000140299a0 9. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:4365: DB::QueryAnalyzer::initializeQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000014043a79 10. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5594: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000140135fb 11. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000140127f9 12. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000014011fce 13. /build/src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000001406ce8a 14. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000014973b42 15. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000001497268d 16. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:205: DB::InterpreterSelectQueryAnalyzer::getSampleBlock(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000014973e7b 17. /build/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) @ 0x0000000016caf5d9 18. /build/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&) @ 0x0000000016cb34a8 19. /build/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*) @ 0x000000001492df0b 20. /build/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) @ 0x000000001492d92e 21. /build/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) @ 0x0000000016cb086b 22. /build/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&) @ 0x0000000016cb34a8 23. /build/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*) @ 0x000000001492df0b 24. /build/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) @ 0x000000001492d92e 25. /build/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) @ 0x0000000016cb086b 26. /build/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&) @ 0x0000000016cb34a8 27. /build/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*) @ 0x000000001492df0b 28. /build/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) @ 0x000000001492d92e 29. /build/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) @ 0x0000000016cb086b 30. /build/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&) @ 0x0000000016cb34a8 31. /build/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*) @ 0x000000001492df0b 2025.07.28 11:52:31.807448 [ 17207 ] {} TCPHandler: Code: 306. DB::Exception: Stack size too large. Stack address: 0x7fb7fddf0000, frame address: 0x7fb7fe1ef100, stack size: 4198144, maximum stack size: 8388608. (TOO_DEEP_RECURSION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, void*&, void const*&, unsigned long&, unsigned long&) @ 0x000000000fc5a24b 4. /build/src/Common/checkStackSize.cpp:151: checkStackSize() @ 0x000000000fc5a14c 5. /build/src/Interpreters/DatabaseCatalog.cpp:338: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x00000000144f0432 6. /build/src/Interpreters/DatabaseCatalog.cpp:984: DB::DatabaseCatalog::tryGetTable(DB::StorageID const&, std::shared_ptr) const @ 0x00000000144f6b77 7. /build/src/Analyzer/Resolve/IdentifierResolver.cpp:177: DB::IdentifierResolver::tryResolveTableIdentifierFromDatabaseCatalog(DB::Identifier const&, std::shared_ptr const&) @ 0x00000000142b9931 8. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:1550: DB::QueryAnalyzer::tryResolveIdentifier(DB::IdentifierLookup const&, DB::IdentifierResolveScope&, DB::IdentifierResolveContext) @ 0x00000000140299a0 9. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:4365: DB::QueryAnalyzer::initializeQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000014043a79 10. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5594: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000140135fb 11. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000140127f9 12. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000014011fce 13. /build/src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000001406ce8a 14. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000014973b42 15. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000001497268d 16. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:205: DB::InterpreterSelectQueryAnalyzer::getSampleBlock(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000014973e7b 17. /build/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) @ 0x0000000016caf5d9 18. /build/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&) @ 0x0000000016cb34a8 19. /build/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*) @ 0x000000001492df0b 20. /build/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) @ 0x000000001492d92e 21. /build/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) @ 0x0000000016cb086b 22. /build/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&) @ 0x0000000016cb34a8 23. /build/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*) @ 0x000000001492df0b 24. /build/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) @ 0x000000001492d92e 25. /build/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) @ 0x0000000016cb086b 26. /build/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&) @ 0x0000000016cb34a8 27. /build/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*) @ 0x000000001492df0b 28. /build/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) @ 0x000000001492d92e 29. /build/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) @ 0x0000000016cb086b 30. /build/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&) @ 0x0000000016cb34a8 31. /build/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*) @ 0x000000001492df0b 2025.07.28 11:52:32.200627 [ 3962 ] {} test_13.rmt2 (7f9b740d-015c-470e-8cc6-8ba33be0dc63): auto DB::StorageReplicatedMergeTree::processQueueEntry(ReplicatedMergeTreeQueue::SelectedEntryPtr)::(anonymous class)::operator()(LogEntryPtr &) const: Code: 86. DB::HTTPException: Received error from remote server http://146b4357c08d:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Ftest%2F01165%2Ftest_13%2Frmt%2Freplicas%2F1&part=20250728_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.6.10636.altinitytest (altinity build)) '. (RECEIVED_ERROR_FROM_REMOTE_IO_SERVER), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.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 const&, int&&, String const&, unsigned long&&, String const&) @ 0x000000000feda8d9 4. /build/src/IO/HTTPCommon.cpp:104: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x000000000feda6e2 5. /build/src/IO/HTTPCommon.cpp:93: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x000000000feda537 6. /build/src/IO/ReadWriteBufferFromHTTP.cpp:277: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x000000001184a4c4 7. /build/src/IO/ReadWriteBufferFromHTTP.cpp:285: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x000000001184a615 8. /build/src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x000000001184ae59 9. /build/src/IO/ReadWriteBufferFromHTTP.cpp:472: void std::__function::__policy_invoker::__call_impl[abi:se190107]>(std::__function::__policy_storage const*) @ 0x000000001184cedd 10. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001184858b 11. /build/src/IO/ReadWriteBufferFromHTTP.cpp:465: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x000000001184bf0b 12. /build/src/IO/ReadBuffer.h:60: DB::ReadBuffer::next() @ 0x000000000a148c7b 13. /build/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) @ 0x0000000011849fb2 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]>&)>&, 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&) @ 0x0000000011841980 15. /build/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) @ 0x000000001621208e 16. /build/src/Storages/StorageReplicatedMergeTree.cpp:5228: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl[abi:se190107] const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000015f9a5fe 17. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000015ed8bfd 18. /build/src/Storages/StorageReplicatedMergeTree.cpp:2514: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x0000000015ec9aab 19. /build/src/Storages/StorageReplicatedMergeTree.cpp:2349: DB::StorageReplicatedMergeTree::executeLogEntry(DB::ReplicatedMergeTreeLogEntry&) @ 0x0000000015eba91b 20. /build/src/Storages/StorageReplicatedMergeTree.cpp:3876: bool std::__function::__policy_invoker&)>::__call_impl[abi:se190107])::$_1, bool (std::shared_ptr&)>>(std::__function::__policy_storage const*, std::shared_ptr&) @ 0x0000000015f9837e 21. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000165d6fc3 22. /build/src/Storages/StorageReplicatedMergeTree.cpp:3872: DB::StorageReplicatedMergeTree::processQueueEntry(std::shared_ptr) @ 0x0000000015efc18a 23. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001624c1b2 24. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000162f9c70 25. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x00000000162fa55a 26. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc6653 27. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000000fccc4c3 28. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc3d92 29. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fcca080 30. ? @ 0x00007fbc6213eac3 31. ? @ 0x00007fbc621d0850 (version 25.3.6.10636.altinitytest (altinity build)) 2025.07.28 11:52:32.406835 [ 3969 ] {} test_13.alter_table1 (b6d50f9f-3cd1-4fee-aa3e-84cf679f8083): Part /var/lib/clickhouse/store/b6d/b6d50f9f-3cd1-4fee-aa3e-84cf679f8083/detached/all_88_88_0/ is broken and needs manual correction. Reason: Code: 226. DB::Exception: No columns.txt in part all_115_115_0, expected path store/b6d/b6d50f9f-3cd1-4fee-aa3e-84cf679f8083/detached/all_88_88_0/columns.txt on drive default. (NO_FILE_IN_DATA_PART), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, String&, String&&) @ 0x0000000012da2e0b 4. /build/src/Storages/MergeTree/IMergeTreeDataPart.cpp:1629: DB::IMergeTreeDataPart::loadColumns(bool) @ 0x000000001625bb62 5. /build/src/Storages/MergeTree/IMergeTreeDataPart.cpp:839: DB::IMergeTreeDataPart::loadColumnsChecksumsIndexes(bool, bool) @ 0x0000000016259f5b 6. /build/src/Storages/StorageReplicatedMergeTree.cpp:2237: DB::StorageReplicatedMergeTree::attachPartHelperFoundValidPart(DB::ReplicatedMergeTreeLogEntry const&) const @ 0x0000000015eb838f 7. /build/src/Storages/StorageReplicatedMergeTree.cpp:2309: DB::StorageReplicatedMergeTree::executeLogEntry(DB::ReplicatedMergeTreeLogEntry&) @ 0x0000000015eb969e 8. /build/src/Storages/StorageReplicatedMergeTree.cpp:3876: bool std::__function::__policy_invoker&)>::__call_impl[abi:se190107])::$_1, bool (std::shared_ptr&)>>(std::__function::__policy_storage const*, std::shared_ptr&) @ 0x0000000015f9837e 9. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000165d6fc3 10. /build/src/Storages/StorageReplicatedMergeTree.cpp:3872: DB::StorageReplicatedMergeTree::processQueueEntry(std::shared_ptr) @ 0x0000000015efc18a 11. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001624c1b2 12. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000162f9c70 13. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x00000000162fa55a 14. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc6653 15. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000000fccc4c3 16. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc3d92 17. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fcca080 18. ? @ 0x00007fbc6213eac3 19. ? @ 0x00007fbc621d0850 (version 25.3.6.10636.altinitytest (altinity build)) 2025.07.28 11:52:32.645590 [ 3972 ] {} test_13.alter_table1 (b6d50f9f-3cd1-4fee-aa3e-84cf679f8083): Part /var/lib/clickhouse/store/b6d/b6d50f9f-3cd1-4fee-aa3e-84cf679f8083/detached/all_88_88_0/ is broken and needs manual correction. Reason: Code: 226. DB::Exception: No columns.txt in part all_117_117_0, expected path store/b6d/b6d50f9f-3cd1-4fee-aa3e-84cf679f8083/detached/all_88_88_0/columns.txt on drive default. (NO_FILE_IN_DATA_PART), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, String&, String&&) @ 0x0000000012da2e0b 4. /build/src/Storages/MergeTree/IMergeTreeDataPart.cpp:1629: DB::IMergeTreeDataPart::loadColumns(bool) @ 0x000000001625bb62 5. /build/src/Storages/MergeTree/IMergeTreeDataPart.cpp:839: DB::IMergeTreeDataPart::loadColumnsChecksumsIndexes(bool, bool) @ 0x0000000016259f5b 6. /build/src/Storages/StorageReplicatedMergeTree.cpp:2237: DB::StorageReplicatedMergeTree::attachPartHelperFoundValidPart(DB::ReplicatedMergeTreeLogEntry const&) const @ 0x0000000015eb838f 7. /build/src/Storages/StorageReplicatedMergeTree.cpp:2309: DB::StorageReplicatedMergeTree::executeLogEntry(DB::ReplicatedMergeTreeLogEntry&) @ 0x0000000015eb969e 8. /build/src/Storages/StorageReplicatedMergeTree.cpp:3876: bool std::__function::__policy_invoker&)>::__call_impl[abi:se190107])::$_1, bool (std::shared_ptr&)>>(std::__function::__policy_storage const*, std::shared_ptr&) @ 0x0000000015f9837e 9. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000165d6fc3 10. /build/src/Storages/StorageReplicatedMergeTree.cpp:3872: DB::StorageReplicatedMergeTree::processQueueEntry(std::shared_ptr) @ 0x0000000015efc18a 11. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001624c1b2 12. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000162f9c70 13. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x00000000162fa55a 14. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc6653 15. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000000fccc4c3 16. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc3d92 17. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fcca080 18. ? @ 0x00007fbc6213eac3 19. ? @ 0x00007fbc621d0850 (version 25.3.6.10636.altinitytest (altinity build)) 2025.07.28 11:52:32.679733 [ 3960 ] {} test_13.rmt2 (7f9b740d-015c-470e-8cc6-8ba33be0dc63): auto DB::StorageReplicatedMergeTree::processQueueEntry(ReplicatedMergeTreeQueue::SelectedEntryPtr)::(anonymous class)::operator()(LogEntryPtr &) const: Code: 86. DB::HTTPException: Received error from remote server http://146b4357c08d:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Ftest%2F01165%2Ftest_13%2Frmt%2Freplicas%2F1&part=20250728_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.6.10636.altinitytest (altinity build)) '. (RECEIVED_ERROR_FROM_REMOTE_IO_SERVER), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.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 const&, int&&, String const&, unsigned long&&, String const&) @ 0x000000000feda8d9 4. /build/src/IO/HTTPCommon.cpp:104: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x000000000feda6e2 5. /build/src/IO/HTTPCommon.cpp:93: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x000000000feda537 6. /build/src/IO/ReadWriteBufferFromHTTP.cpp:277: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x000000001184a4c4 7. /build/src/IO/ReadWriteBufferFromHTTP.cpp:285: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x000000001184a615 8. /build/src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x000000001184ae59 9. /build/src/IO/ReadWriteBufferFromHTTP.cpp:472: void std::__function::__policy_invoker::__call_impl[abi:se190107]>(std::__function::__policy_storage const*) @ 0x000000001184cedd 10. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001184858b 11. /build/src/IO/ReadWriteBufferFromHTTP.cpp:465: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x000000001184bf0b 12. /build/src/IO/ReadBuffer.h:60: DB::ReadBuffer::next() @ 0x000000000a148c7b 13. /build/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) @ 0x0000000011849fb2 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]>&)>&, 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&) @ 0x0000000011841980 15. /build/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) @ 0x000000001621208e 16. /build/src/Storages/StorageReplicatedMergeTree.cpp:5228: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl[abi:se190107] const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000015f9a5fe 17. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000015ed8bfd 18. /build/src/Storages/StorageReplicatedMergeTree.cpp:2514: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x0000000015ec9aab 19. /build/src/Storages/StorageReplicatedMergeTree.cpp:2349: DB::StorageReplicatedMergeTree::executeLogEntry(DB::ReplicatedMergeTreeLogEntry&) @ 0x0000000015eba91b 20. /build/src/Storages/StorageReplicatedMergeTree.cpp:3876: bool std::__function::__policy_invoker&)>::__call_impl[abi:se190107])::$_1, bool (std::shared_ptr&)>>(std::__function::__policy_storage const*, std::shared_ptr&) @ 0x0000000015f9837e 21. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000165d6fc3 22. /build/src/Storages/StorageReplicatedMergeTree.cpp:3872: DB::StorageReplicatedMergeTree::processQueueEntry(std::shared_ptr) @ 0x0000000015efc18a 23. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001624c1b2 24. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000162f9c70 25. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x00000000162fa55a 26. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc6653 27. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000000fccc4c3 28. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc3d92 29. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fcca080 30. ? @ 0x00007fbc6213eac3 31. ? @ 0x00007fbc621d0850 (version 25.3.6.10636.altinitytest (altinity build)) 2025.07.28 11:52:32.917862 [ 3965 ] {} test_13.alter_table1 (b6d50f9f-3cd1-4fee-aa3e-84cf679f8083): Part /var/lib/clickhouse/store/b6d/b6d50f9f-3cd1-4fee-aa3e-84cf679f8083/detached/all_81_81_0/ is broken and needs manual correction. Reason: Code: 226. DB::Exception: No columns.txt in part all_118_118_0, expected path store/b6d/b6d50f9f-3cd1-4fee-aa3e-84cf679f8083/detached/all_81_81_0/columns.txt on drive default. (NO_FILE_IN_DATA_PART), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, String&, String&&) @ 0x0000000012da2e0b 4. /build/src/Storages/MergeTree/IMergeTreeDataPart.cpp:1629: DB::IMergeTreeDataPart::loadColumns(bool) @ 0x000000001625bb62 5. /build/src/Storages/MergeTree/IMergeTreeDataPart.cpp:839: DB::IMergeTreeDataPart::loadColumnsChecksumsIndexes(bool, bool) @ 0x0000000016259f5b 6. /build/src/Storages/StorageReplicatedMergeTree.cpp:2237: DB::StorageReplicatedMergeTree::attachPartHelperFoundValidPart(DB::ReplicatedMergeTreeLogEntry const&) const @ 0x0000000015eb838f 7. /build/src/Storages/StorageReplicatedMergeTree.cpp:2309: DB::StorageReplicatedMergeTree::executeLogEntry(DB::ReplicatedMergeTreeLogEntry&) @ 0x0000000015eb969e 8. /build/src/Storages/StorageReplicatedMergeTree.cpp:3876: bool std::__function::__policy_invoker&)>::__call_impl[abi:se190107])::$_1, bool (std::shared_ptr&)>>(std::__function::__policy_storage const*, std::shared_ptr&) @ 0x0000000015f9837e 9. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000165d6fc3 10. /build/src/Storages/StorageReplicatedMergeTree.cpp:3872: DB::StorageReplicatedMergeTree::processQueueEntry(std::shared_ptr) @ 0x0000000015efc18a 11. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001624c1b2 12. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000162f9c70 13. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x00000000162fa55a 14. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc6653 15. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000000fccc4c3 16. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc3d92 17. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fcca080 18. ? @ 0x00007fbc6213eac3 19. ? @ 0x00007fbc621d0850 (version 25.3.6.10636.altinitytest (altinity build)) 2025.07.28 11:52:33.356887 [ 5879 ] {95b15056-7ee1-4f25-b110-92577e6bc9c5} executeQuery: Code: 42. DB::Exception: Storage ODBC requires exactly 3 parameters: ODBC('DSN', database or schema, table). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.6.10636.altinitytest (altinity build)) (from [::1]:36672) (comment: 01033_storage_odbc_parsing_exception_check.sql) (query 2, line 5) (in query: CREATE TABLE BannerDict (`BannerID` UInt64, `CompaignID` UInt64) ENGINE = ODBC('DSN=pgconn;Database=postgres', bannerdict);), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String const&) @ 0x000000000a07198b 4. /build/src/Storages/StorageXDBC.cpp:188: std::shared_ptr std::__function::__policy_invoker (DB::StorageFactory::Arguments const&)>::__call_impl[abi:se190107](DB::StorageFactory&, String const&)::'lambda'(DB::StorageFactory::Arguments const&), std::shared_ptr (DB::StorageFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::StorageFactory::Arguments const&) @ 0x000000001603a3e1 5. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000015d81ea2 6. /build/src/Interpreters/InterpreterCreateQuery.cpp:1945: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x00000000149009bb 7. /build/src/Interpreters/InterpreterCreateQuery.cpp:1743: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000148f9aa9 8. /build/src/Interpreters/InterpreterCreateQuery.cpp:2352: DB::InterpreterCreateQuery::execute() @ 0x0000000014905a41 9. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88dc9 10. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 11. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 12. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 13. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 14. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 16. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 17. ? @ 0x00007fbc6213eac3 18. ? @ 0x00007fbc621d0850 2025.07.28 11:52:33.365709 [ 5879 ] {} TCPHandler: Code: 42. DB::Exception: Storage ODBC requires exactly 3 parameters: ODBC('DSN', database or schema, table). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String const&) @ 0x000000000a07198b 4. /build/src/Storages/StorageXDBC.cpp:188: std::shared_ptr std::__function::__policy_invoker (DB::StorageFactory::Arguments const&)>::__call_impl[abi:se190107](DB::StorageFactory&, String const&)::'lambda'(DB::StorageFactory::Arguments const&), std::shared_ptr (DB::StorageFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::StorageFactory::Arguments const&) @ 0x000000001603a3e1 5. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000015d81ea2 6. /build/src/Interpreters/InterpreterCreateQuery.cpp:1945: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x00000000149009bb 7. /build/src/Interpreters/InterpreterCreateQuery.cpp:1743: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000148f9aa9 8. /build/src/Interpreters/InterpreterCreateQuery.cpp:2352: DB::InterpreterCreateQuery::execute() @ 0x0000000014905a41 9. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88dc9 10. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 11. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 12. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 13. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 14. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 16. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 17. ? @ 0x00007fbc6213eac3 18. ? @ 0x00007fbc621d0850 2025.07.28 11:52:33.897257 [ 3963 ] {} test_13.rmt2 (7f9b740d-015c-470e-8cc6-8ba33be0dc63): auto DB::StorageReplicatedMergeTree::processQueueEntry(ReplicatedMergeTreeQueue::SelectedEntryPtr)::(anonymous class)::operator()(LogEntryPtr &) const: Code: 86. DB::HTTPException: Received error from remote server http://146b4357c08d:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Ftest%2F01165%2Ftest_13%2Frmt%2Freplicas%2F1&part=20250728_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.6.10636.altinitytest (altinity build)) '. (RECEIVED_ERROR_FROM_REMOTE_IO_SERVER), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.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 const&, int&&, String const&, unsigned long&&, String const&) @ 0x000000000feda8d9 4. /build/src/IO/HTTPCommon.cpp:104: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x000000000feda6e2 5. /build/src/IO/HTTPCommon.cpp:93: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x000000000feda537 6. /build/src/IO/ReadWriteBufferFromHTTP.cpp:277: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x000000001184a4c4 7. /build/src/IO/ReadWriteBufferFromHTTP.cpp:285: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x000000001184a615 8. /build/src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x000000001184ae59 9. /build/src/IO/ReadWriteBufferFromHTTP.cpp:472: void std::__function::__policy_invoker::__call_impl[abi:se190107]>(std::__function::__policy_storage const*) @ 0x000000001184cedd 10. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001184858b 11. /build/src/IO/ReadWriteBufferFromHTTP.cpp:465: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x000000001184bf0b 12. /build/src/IO/ReadBuffer.h:60: DB::ReadBuffer::next() @ 0x000000000a148c7b 13. /build/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) @ 0x0000000011849fb2 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]>&)>&, 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&) @ 0x0000000011841980 15. /build/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) @ 0x000000001621208e 16. /build/src/Storages/StorageReplicatedMergeTree.cpp:5228: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl[abi:se190107] const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000015f9a5fe 17. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000015ed8bfd 18. /build/src/Storages/StorageReplicatedMergeTree.cpp:2514: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x0000000015ec9aab 19. /build/src/Storages/StorageReplicatedMergeTree.cpp:2349: DB::StorageReplicatedMergeTree::executeLogEntry(DB::ReplicatedMergeTreeLogEntry&) @ 0x0000000015eba91b 20. /build/src/Storages/StorageReplicatedMergeTree.cpp:3876: bool std::__function::__policy_invoker&)>::__call_impl[abi:se190107])::$_1, bool (std::shared_ptr&)>>(std::__function::__policy_storage const*, std::shared_ptr&) @ 0x0000000015f9837e 21. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000165d6fc3 22. /build/src/Storages/StorageReplicatedMergeTree.cpp:3872: DB::StorageReplicatedMergeTree::processQueueEntry(std::shared_ptr) @ 0x0000000015efc18a 23. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001624c1b2 24. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000162f9c70 25. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x00000000162fa55a 26. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc6653 27. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000000fccc4c3 28. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc3d92 29. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fcca080 30. ? @ 0x00007fbc6213eac3 31. ? @ 0x00007fbc621d0850 (version 25.3.6.10636.altinitytest (altinity build)) 2025.07.28 11:52:33.906818 [ 3970 ] {} test_13.alter_table1 (b6d50f9f-3cd1-4fee-aa3e-84cf679f8083): Part /var/lib/clickhouse/store/b6d/b6d50f9f-3cd1-4fee-aa3e-84cf679f8083/detached/all_68_68_0/ is broken and needs manual correction. Reason: Code: 226. DB::Exception: No columns.txt in part all_122_122_0, expected path store/b6d/b6d50f9f-3cd1-4fee-aa3e-84cf679f8083/detached/all_68_68_0/columns.txt on drive default. (NO_FILE_IN_DATA_PART), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, String&, String&&) @ 0x0000000012da2e0b 4. /build/src/Storages/MergeTree/IMergeTreeDataPart.cpp:1629: DB::IMergeTreeDataPart::loadColumns(bool) @ 0x000000001625bb62 5. /build/src/Storages/MergeTree/IMergeTreeDataPart.cpp:839: DB::IMergeTreeDataPart::loadColumnsChecksumsIndexes(bool, bool) @ 0x0000000016259f5b 6. /build/src/Storages/StorageReplicatedMergeTree.cpp:2237: DB::StorageReplicatedMergeTree::attachPartHelperFoundValidPart(DB::ReplicatedMergeTreeLogEntry const&) const @ 0x0000000015eb838f 7. /build/src/Storages/StorageReplicatedMergeTree.cpp:2309: DB::StorageReplicatedMergeTree::executeLogEntry(DB::ReplicatedMergeTreeLogEntry&) @ 0x0000000015eb969e 8. /build/src/Storages/StorageReplicatedMergeTree.cpp:3876: bool std::__function::__policy_invoker&)>::__call_impl[abi:se190107])::$_1, bool (std::shared_ptr&)>>(std::__function::__policy_storage const*, std::shared_ptr&) @ 0x0000000015f9837e 9. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000165d6fc3 10. /build/src/Storages/StorageReplicatedMergeTree.cpp:3872: DB::StorageReplicatedMergeTree::processQueueEntry(std::shared_ptr) @ 0x0000000015efc18a 11. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001624c1b2 12. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000162f9c70 13. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x00000000162fa55a 14. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc6653 15. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000000fccc4c3 16. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc3d92 17. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fcca080 18. ? @ 0x00007fbc6213eac3 19. ? @ 0x00007fbc621d0850 (version 25.3.6.10636.altinitytest (altinity build)) 2025.07.28 11:52:33.977197 [ 3968 ] {} test_13.alter_table1 (b6d50f9f-3cd1-4fee-aa3e-84cf679f8083): Part /var/lib/clickhouse/store/b6d/b6d50f9f-3cd1-4fee-aa3e-84cf679f8083/detached/all_68_68_0/ is broken and needs manual correction. Reason: Code: 226. DB::Exception: No columns.txt in part all_124_124_0, expected path store/b6d/b6d50f9f-3cd1-4fee-aa3e-84cf679f8083/detached/all_68_68_0/columns.txt on drive default. (NO_FILE_IN_DATA_PART), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, String&, String&&) @ 0x0000000012da2e0b 4. /build/src/Storages/MergeTree/IMergeTreeDataPart.cpp:1629: DB::IMergeTreeDataPart::loadColumns(bool) @ 0x000000001625bb62 5. /build/src/Storages/MergeTree/IMergeTreeDataPart.cpp:839: DB::IMergeTreeDataPart::loadColumnsChecksumsIndexes(bool, bool) @ 0x0000000016259f5b 6. /build/src/Storages/StorageReplicatedMergeTree.cpp:2237: DB::StorageReplicatedMergeTree::attachPartHelperFoundValidPart(DB::ReplicatedMergeTreeLogEntry const&) const @ 0x0000000015eb838f 7. /build/src/Storages/StorageReplicatedMergeTree.cpp:2309: DB::StorageReplicatedMergeTree::executeLogEntry(DB::ReplicatedMergeTreeLogEntry&) @ 0x0000000015eb969e 8. /build/src/Storages/StorageReplicatedMergeTree.cpp:3876: bool std::__function::__policy_invoker&)>::__call_impl[abi:se190107])::$_1, bool (std::shared_ptr&)>>(std::__function::__policy_storage const*, std::shared_ptr&) @ 0x0000000015f9837e 9. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000165d6fc3 10. /build/src/Storages/StorageReplicatedMergeTree.cpp:3872: DB::StorageReplicatedMergeTree::processQueueEntry(std::shared_ptr) @ 0x0000000015efc18a 11. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001624c1b2 12. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000162f9c70 13. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x00000000162fa55a 14. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc6653 15. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000000fccc4c3 16. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc3d92 17. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fcca080 18. ? @ 0x00007fbc6213eac3 19. ? @ 0x00007fbc621d0850 (version 25.3.6.10636.altinitytest (altinity build)) 2025.07.28 11:52:34.180736 [ 3968 ] {} test_13.alter_table1 (b6d50f9f-3cd1-4fee-aa3e-84cf679f8083): Part /var/lib/clickhouse/store/b6d/b6d50f9f-3cd1-4fee-aa3e-84cf679f8083/detached/all_78_78_0/ is broken and needs manual correction. Reason: Code: 226. DB::Exception: No columns.txt in part all_124_124_0, expected path store/b6d/b6d50f9f-3cd1-4fee-aa3e-84cf679f8083/detached/all_78_78_0/columns.txt on drive default. (NO_FILE_IN_DATA_PART), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, String&, String&&) @ 0x0000000012da2e0b 4. /build/src/Storages/MergeTree/IMergeTreeDataPart.cpp:1629: DB::IMergeTreeDataPart::loadColumns(bool) @ 0x000000001625bb62 5. /build/src/Storages/MergeTree/IMergeTreeDataPart.cpp:839: DB::IMergeTreeDataPart::loadColumnsChecksumsIndexes(bool, bool) @ 0x0000000016259f5b 6. /build/src/Storages/StorageReplicatedMergeTree.cpp:2237: DB::StorageReplicatedMergeTree::attachPartHelperFoundValidPart(DB::ReplicatedMergeTreeLogEntry const&) const @ 0x0000000015eb838f 7. /build/src/Storages/StorageReplicatedMergeTree.cpp:2309: DB::StorageReplicatedMergeTree::executeLogEntry(DB::ReplicatedMergeTreeLogEntry&) @ 0x0000000015eb969e 8. /build/src/Storages/StorageReplicatedMergeTree.cpp:3876: bool std::__function::__policy_invoker&)>::__call_impl[abi:se190107])::$_1, bool (std::shared_ptr&)>>(std::__function::__policy_storage const*, std::shared_ptr&) @ 0x0000000015f9837e 9. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000165d6fc3 10. /build/src/Storages/StorageReplicatedMergeTree.cpp:3872: DB::StorageReplicatedMergeTree::processQueueEntry(std::shared_ptr) @ 0x0000000015efc18a 11. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001624c1b2 12. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000162f9c70 13. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x00000000162fa55a 14. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc6653 15. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000000fccc4c3 16. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc3d92 17. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fcca080 18. ? @ 0x00007fbc6213eac3 19. ? @ 0x00007fbc621d0850 (version 25.3.6.10636.altinitytest (altinity build)) 2025.07.28 11:52:34.240930 [ 3977 ] {} test_13.alter_table1 (b6d50f9f-3cd1-4fee-aa3e-84cf679f8083): Part /var/lib/clickhouse/store/b6d/b6d50f9f-3cd1-4fee-aa3e-84cf679f8083/detached/all_91_91_0/ is broken and needs manual correction. Reason: Code: 226. DB::Exception: No columns.txt in part all_125_125_0, expected path store/b6d/b6d50f9f-3cd1-4fee-aa3e-84cf679f8083/detached/all_91_91_0/columns.txt on drive default. (NO_FILE_IN_DATA_PART), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, String&, String&&) @ 0x0000000012da2e0b 4. /build/src/Storages/MergeTree/IMergeTreeDataPart.cpp:1629: DB::IMergeTreeDataPart::loadColumns(bool) @ 0x000000001625bb62 5. /build/src/Storages/MergeTree/IMergeTreeDataPart.cpp:839: DB::IMergeTreeDataPart::loadColumnsChecksumsIndexes(bool, bool) @ 0x0000000016259f5b 6. /build/src/Storages/StorageReplicatedMergeTree.cpp:2237: DB::StorageReplicatedMergeTree::attachPartHelperFoundValidPart(DB::ReplicatedMergeTreeLogEntry const&) const @ 0x0000000015eb838f 7. /build/src/Storages/StorageReplicatedMergeTree.cpp:2309: DB::StorageReplicatedMergeTree::executeLogEntry(DB::ReplicatedMergeTreeLogEntry&) @ 0x0000000015eb969e 8. /build/src/Storages/StorageReplicatedMergeTree.cpp:3876: bool std::__function::__policy_invoker&)>::__call_impl[abi:se190107])::$_1, bool (std::shared_ptr&)>>(std::__function::__policy_storage const*, std::shared_ptr&) @ 0x0000000015f9837e 9. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000165d6fc3 10. /build/src/Storages/StorageReplicatedMergeTree.cpp:3872: DB::StorageReplicatedMergeTree::processQueueEntry(std::shared_ptr) @ 0x0000000015efc18a 11. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001624c1b2 12. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000162f9c70 13. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x00000000162fa55a 14. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc6653 15. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000000fccc4c3 16. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc3d92 17. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fcca080 18. ? @ 0x00007fbc6213eac3 19. ? @ 0x00007fbc621d0850 (version 25.3.6.10636.altinitytest (altinity build)) 2025.07.28 11:52:34.527646 [ 3977 ] {} test_13.alter_table1 (b6d50f9f-3cd1-4fee-aa3e-84cf679f8083): Part /var/lib/clickhouse/store/b6d/b6d50f9f-3cd1-4fee-aa3e-84cf679f8083/detached/all_78_78_0/ is broken and needs manual correction. Reason: Code: 226. DB::Exception: No columns.txt in part all_125_125_0, expected path store/b6d/b6d50f9f-3cd1-4fee-aa3e-84cf679f8083/detached/all_78_78_0/columns.txt on drive default. (NO_FILE_IN_DATA_PART), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, String&, String&&) @ 0x0000000012da2e0b 4. /build/src/Storages/MergeTree/IMergeTreeDataPart.cpp:1629: DB::IMergeTreeDataPart::loadColumns(bool) @ 0x000000001625bb62 5. /build/src/Storages/MergeTree/IMergeTreeDataPart.cpp:839: DB::IMergeTreeDataPart::loadColumnsChecksumsIndexes(bool, bool) @ 0x0000000016259f5b 6. /build/src/Storages/StorageReplicatedMergeTree.cpp:2237: DB::StorageReplicatedMergeTree::attachPartHelperFoundValidPart(DB::ReplicatedMergeTreeLogEntry const&) const @ 0x0000000015eb838f 7. /build/src/Storages/StorageReplicatedMergeTree.cpp:2309: DB::StorageReplicatedMergeTree::executeLogEntry(DB::ReplicatedMergeTreeLogEntry&) @ 0x0000000015eb969e 8. /build/src/Storages/StorageReplicatedMergeTree.cpp:3876: bool std::__function::__policy_invoker&)>::__call_impl[abi:se190107])::$_1, bool (std::shared_ptr&)>>(std::__function::__policy_storage const*, std::shared_ptr&) @ 0x0000000015f9837e 9. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000165d6fc3 10. /build/src/Storages/StorageReplicatedMergeTree.cpp:3872: DB::StorageReplicatedMergeTree::processQueueEntry(std::shared_ptr) @ 0x0000000015efc18a 11. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001624c1b2 12. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000162f9c70 13. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x00000000162fa55a 14. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc6653 15. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000000fccc4c3 16. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc3d92 17. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fcca080 18. ? @ 0x00007fbc6213eac3 19. ? @ 0x00007fbc621d0850 (version 25.3.6.10636.altinitytest (altinity build)) 2025.07.28 11:52:34.548496 [ 3965 ] {} test_13.rmt2 (7f9b740d-015c-470e-8cc6-8ba33be0dc63): auto DB::StorageReplicatedMergeTree::processQueueEntry(ReplicatedMergeTreeQueue::SelectedEntryPtr)::(anonymous class)::operator()(LogEntryPtr &) const: Code: 86. DB::HTTPException: Received error from remote server http://146b4357c08d:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Ftest%2F01165%2Ftest_13%2Frmt%2Freplicas%2F1&part=20250728_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.6.10636.altinitytest (altinity build)) '. (RECEIVED_ERROR_FROM_REMOTE_IO_SERVER), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.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 const&, int&&, String const&, unsigned long&&, String const&) @ 0x000000000feda8d9 4. /build/src/IO/HTTPCommon.cpp:104: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x000000000feda6e2 5. /build/src/IO/HTTPCommon.cpp:93: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x000000000feda537 6. /build/src/IO/ReadWriteBufferFromHTTP.cpp:277: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x000000001184a4c4 7. /build/src/IO/ReadWriteBufferFromHTTP.cpp:285: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x000000001184a615 8. /build/src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x000000001184ae59 9. /build/src/IO/ReadWriteBufferFromHTTP.cpp:472: void std::__function::__policy_invoker::__call_impl[abi:se190107]>(std::__function::__policy_storage const*) @ 0x000000001184cedd 10. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001184858b 11. /build/src/IO/ReadWriteBufferFromHTTP.cpp:465: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x000000001184bf0b 12. /build/src/IO/ReadBuffer.h:60: DB::ReadBuffer::next() @ 0x000000000a148c7b 13. /build/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) @ 0x0000000011849fb2 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]>&)>&, 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&) @ 0x0000000011841980 15. /build/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) @ 0x000000001621208e 16. /build/src/Storages/StorageReplicatedMergeTree.cpp:5228: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl[abi:se190107] const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000015f9a5fe 17. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000015ed8bfd 18. /build/src/Storages/StorageReplicatedMergeTree.cpp:2514: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x0000000015ec9aab 19. /build/src/Storages/StorageReplicatedMergeTree.cpp:2349: DB::StorageReplicatedMergeTree::executeLogEntry(DB::ReplicatedMergeTreeLogEntry&) @ 0x0000000015eba91b 20. /build/src/Storages/StorageReplicatedMergeTree.cpp:3876: bool std::__function::__policy_invoker&)>::__call_impl[abi:se190107])::$_1, bool (std::shared_ptr&)>>(std::__function::__policy_storage const*, std::shared_ptr&) @ 0x0000000015f9837e 21. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000165d6fc3 22. /build/src/Storages/StorageReplicatedMergeTree.cpp:3872: DB::StorageReplicatedMergeTree::processQueueEntry(std::shared_ptr) @ 0x0000000015efc18a 23. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001624c1b2 24. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000162f9c70 25. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x00000000162fa55a 26. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc6653 27. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000000fccc4c3 28. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc3d92 29. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fcca080 30. ? @ 0x00007fbc6213eac3 31. ? @ 0x00007fbc621d0850 (version 25.3.6.10636.altinitytest (altinity build)) 2025.07.28 11:52:35.053268 [ 3972 ] {} test_13.alter_table1 (b6d50f9f-3cd1-4fee-aa3e-84cf679f8083): Part /var/lib/clickhouse/store/b6d/b6d50f9f-3cd1-4fee-aa3e-84cf679f8083/detached/all_79_79_0/ is broken and needs manual correction. Reason: Code: 226. DB::Exception: No columns.txt in part all_126_126_0, expected path store/b6d/b6d50f9f-3cd1-4fee-aa3e-84cf679f8083/detached/all_79_79_0/columns.txt on drive default. (NO_FILE_IN_DATA_PART), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, String&, String&&) @ 0x0000000012da2e0b 4. /build/src/Storages/MergeTree/IMergeTreeDataPart.cpp:1629: DB::IMergeTreeDataPart::loadColumns(bool) @ 0x000000001625bb62 5. /build/src/Storages/MergeTree/IMergeTreeDataPart.cpp:839: DB::IMergeTreeDataPart::loadColumnsChecksumsIndexes(bool, bool) @ 0x0000000016259f5b 6. /build/src/Storages/StorageReplicatedMergeTree.cpp:2237: DB::StorageReplicatedMergeTree::attachPartHelperFoundValidPart(DB::ReplicatedMergeTreeLogEntry const&) const @ 0x0000000015eb838f 7. /build/src/Storages/StorageReplicatedMergeTree.cpp:2309: DB::StorageReplicatedMergeTree::executeLogEntry(DB::ReplicatedMergeTreeLogEntry&) @ 0x0000000015eb969e 8. /build/src/Storages/StorageReplicatedMergeTree.cpp:3876: bool std::__function::__policy_invoker&)>::__call_impl[abi:se190107])::$_1, bool (std::shared_ptr&)>>(std::__function::__policy_storage const*, std::shared_ptr&) @ 0x0000000015f9837e 9. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000165d6fc3 10. /build/src/Storages/StorageReplicatedMergeTree.cpp:3872: DB::StorageReplicatedMergeTree::processQueueEntry(std::shared_ptr) @ 0x0000000015efc18a 11. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001624c1b2 12. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000162f9c70 13. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x00000000162fa55a 14. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc6653 15. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000000fccc4c3 16. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc3d92 17. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fcca080 18. ? @ 0x00007fbc6213eac3 19. ? @ 0x00007fbc621d0850 (version 25.3.6.10636.altinitytest (altinity build)) 2025.07.28 11:52:35.276793 [ 3963 ] {} test_13.rmt2 (7f9b740d-015c-470e-8cc6-8ba33be0dc63): auto DB::StorageReplicatedMergeTree::processQueueEntry(ReplicatedMergeTreeQueue::SelectedEntryPtr)::(anonymous class)::operator()(LogEntryPtr &) const: Code: 86. DB::HTTPException: Received error from remote server http://146b4357c08d:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Ftest%2F01165%2Ftest_13%2Frmt%2Freplicas%2F1&part=20250728_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.6.10636.altinitytest (altinity build)) '. (RECEIVED_ERROR_FROM_REMOTE_IO_SERVER), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.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 const&, int&&, String const&, unsigned long&&, String const&) @ 0x000000000feda8d9 4. /build/src/IO/HTTPCommon.cpp:104: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x000000000feda6e2 5. /build/src/IO/HTTPCommon.cpp:93: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x000000000feda537 6. /build/src/IO/ReadWriteBufferFromHTTP.cpp:277: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x000000001184a4c4 7. /build/src/IO/ReadWriteBufferFromHTTP.cpp:285: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x000000001184a615 8. /build/src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x000000001184ae59 9. /build/src/IO/ReadWriteBufferFromHTTP.cpp:472: void std::__function::__policy_invoker::__call_impl[abi:se190107]>(std::__function::__policy_storage const*) @ 0x000000001184cedd 10. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001184858b 11. /build/src/IO/ReadWriteBufferFromHTTP.cpp:465: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x000000001184bf0b 12. /build/src/IO/ReadBuffer.h:60: DB::ReadBuffer::next() @ 0x000000000a148c7b 13. /build/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) @ 0x0000000011849fb2 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]>&)>&, 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&) @ 0x0000000011841980 15. /build/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) @ 0x000000001621208e 16. /build/src/Storages/StorageReplicatedMergeTree.cpp:5228: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl[abi:se190107] const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000015f9a5fe 17. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000015ed8bfd 18. /build/src/Storages/StorageReplicatedMergeTree.cpp:2514: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x0000000015ec9aab 19. /build/src/Storages/StorageReplicatedMergeTree.cpp:2349: DB::StorageReplicatedMergeTree::executeLogEntry(DB::ReplicatedMergeTreeLogEntry&) @ 0x0000000015eba91b 20. /build/src/Storages/StorageReplicatedMergeTree.cpp:3876: bool std::__function::__policy_invoker&)>::__call_impl[abi:se190107])::$_1, bool (std::shared_ptr&)>>(std::__function::__policy_storage const*, std::shared_ptr&) @ 0x0000000015f9837e 21. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000165d6fc3 22. /build/src/Storages/StorageReplicatedMergeTree.cpp:3872: DB::StorageReplicatedMergeTree::processQueueEntry(std::shared_ptr) @ 0x0000000015efc18a 23. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001624c1b2 24. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000162f9c70 25. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x00000000162fa55a 26. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc6653 27. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000000fccc4c3 28. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc3d92 29. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fcca080 30. ? @ 0x00007fbc6213eac3 31. ? @ 0x00007fbc621d0850 (version 25.3.6.10636.altinitytest (altinity build)) 2025.07.28 11:52:36.181506 [ 17203 ] {dc46b1b5-fd75-40bf-b754-312e550f168a} executeQuery: Code: 47. DB::Exception: Unknown expression or function identifier `x` in scope x = 1. Maybe you meant: ['p']. (UNKNOWN_IDENTIFIER) (version 25.3.6.10636.altinitytest (altinity build)) (from [::1]:36734) (comment: 01300_svg.sql) (query 14, line 15) (in query: SELECT SVG(p) FROM geo ORDER BY id;), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.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&&) @ 0x000000001404b3b9 4. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3771: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000001401b849 5. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3980: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000014018e31 6. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:2925: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000001402fcbd 7. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3838: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000014019a9e 8. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:209: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000001401270e 9. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000014011fce 10. /build/src/Planner/Utils.cpp:458: DB::buildFilterInfo(std::shared_ptr, std::shared_ptr const&, std::shared_ptr&, std::unordered_set, std::equal_to, std::allocator>) @ 0x0000000013fe8bcf 11. /build/src/Planner/PlannerJoinTree.cpp:535: DB::(anonymous namespace)::buildQueryPlanForTableExpression(std::shared_ptr, std::shared_ptr const&, DB::SelectQueryInfo const&, DB::SelectQueryOptions const&, std::shared_ptr&, bool, bool) @ 0x00000000149956d3 12. /build/src/Planner/PlannerJoinTree.cpp:2252: DB::buildJoinTreeQueryPlan(std::shared_ptr const&, DB::SelectQueryInfo const&, DB::SelectQueryOptions&, std::unordered_set, std::equal_to, std::allocator> const&, std::shared_ptr&) @ 0x000000001498e109 13. /build/src/Planner/Planner.cpp:1553: DB::Planner::buildPlanForQueryNode() @ 0x0000000014979dae 14. /build/src/Planner/Planner.cpp:1308: DB::Planner::buildQueryPlanIfNeeded() @ 0x000000001497685c 15. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:255: DB::InterpreterSelectQueryAnalyzer::getQueryPlan() @ 0x000000001497476d 16. /build/src/Interpreters/executeQuery.cpp:1405: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88806 17. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 18. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 19. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 20. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 21. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 22. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 23. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 24. ? @ 0x00007fbc6213eac3 25. ? @ 0x00007fbc621d0850 2025.07.28 11:52:36.185627 [ 17203 ] {} TCPHandler: Code: 47. DB::Exception: Unknown expression or function identifier `x` in scope x = 1. Maybe you meant: ['p']. (UNKNOWN_IDENTIFIER), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.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&&) @ 0x000000001404b3b9 4. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3771: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000001401b849 5. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3980: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000014018e31 6. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:2925: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000001402fcbd 7. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3838: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000014019a9e 8. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:209: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000001401270e 9. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000014011fce 10. /build/src/Planner/Utils.cpp:458: DB::buildFilterInfo(std::shared_ptr, std::shared_ptr const&, std::shared_ptr&, std::unordered_set, std::equal_to, std::allocator>) @ 0x0000000013fe8bcf 11. /build/src/Planner/PlannerJoinTree.cpp:535: DB::(anonymous namespace)::buildQueryPlanForTableExpression(std::shared_ptr, std::shared_ptr const&, DB::SelectQueryInfo const&, DB::SelectQueryOptions const&, std::shared_ptr&, bool, bool) @ 0x00000000149956d3 12. /build/src/Planner/PlannerJoinTree.cpp:2252: DB::buildJoinTreeQueryPlan(std::shared_ptr const&, DB::SelectQueryInfo const&, DB::SelectQueryOptions&, std::unordered_set, std::equal_to, std::allocator> const&, std::shared_ptr&) @ 0x000000001498e109 13. /build/src/Planner/Planner.cpp:1553: DB::Planner::buildPlanForQueryNode() @ 0x0000000014979dae 14. /build/src/Planner/Planner.cpp:1308: DB::Planner::buildQueryPlanIfNeeded() @ 0x000000001497685c 15. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:255: DB::InterpreterSelectQueryAnalyzer::getQueryPlan() @ 0x000000001497476d 16. /build/src/Interpreters/executeQuery.cpp:1405: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88806 17. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 18. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 19. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 20. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 21. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 22. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 23. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 24. ? @ 0x00007fbc6213eac3 25. ? @ 0x00007fbc621d0850 2025.07.28 11:52:36.231298 [ 3968 ] {} test_13.rmt2 (7f9b740d-015c-470e-8cc6-8ba33be0dc63): auto DB::StorageReplicatedMergeTree::processQueueEntry(ReplicatedMergeTreeQueue::SelectedEntryPtr)::(anonymous class)::operator()(LogEntryPtr &) const: Code: 86. DB::HTTPException: Received error from remote server http://146b4357c08d:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Ftest%2F01165%2Ftest_13%2Frmt%2Freplicas%2F1&part=20250728_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.6.10636.altinitytest (altinity build)) '. (RECEIVED_ERROR_FROM_REMOTE_IO_SERVER), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.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 const&, int&&, String const&, unsigned long&&, String const&) @ 0x000000000feda8d9 4. /build/src/IO/HTTPCommon.cpp:104: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x000000000feda6e2 5. /build/src/IO/HTTPCommon.cpp:93: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x000000000feda537 6. /build/src/IO/ReadWriteBufferFromHTTP.cpp:277: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x000000001184a4c4 7. /build/src/IO/ReadWriteBufferFromHTTP.cpp:285: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x000000001184a615 8. /build/src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x000000001184ae59 9. /build/src/IO/ReadWriteBufferFromHTTP.cpp:472: void std::__function::__policy_invoker::__call_impl[abi:se190107]>(std::__function::__policy_storage const*) @ 0x000000001184cedd 10. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001184858b 11. /build/src/IO/ReadWriteBufferFromHTTP.cpp:465: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x000000001184bf0b 12. /build/src/IO/ReadBuffer.h:60: DB::ReadBuffer::next() @ 0x000000000a148c7b 13. /build/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) @ 0x0000000011849fb2 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]>&)>&, 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&) @ 0x0000000011841980 15. /build/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) @ 0x000000001621208e 16. /build/src/Storages/StorageReplicatedMergeTree.cpp:5228: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl[abi:se190107] const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000015f9a5fe 17. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000015ed8bfd 18. /build/src/Storages/StorageReplicatedMergeTree.cpp:2514: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x0000000015ec9aab 19. /build/src/Storages/StorageReplicatedMergeTree.cpp:2349: DB::StorageReplicatedMergeTree::executeLogEntry(DB::ReplicatedMergeTreeLogEntry&) @ 0x0000000015eba91b 20. /build/src/Storages/StorageReplicatedMergeTree.cpp:3876: bool std::__function::__policy_invoker&)>::__call_impl[abi:se190107])::$_1, bool (std::shared_ptr&)>>(std::__function::__policy_storage const*, std::shared_ptr&) @ 0x0000000015f9837e 21. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000165d6fc3 22. /build/src/Storages/StorageReplicatedMergeTree.cpp:3872: DB::StorageReplicatedMergeTree::processQueueEntry(std::shared_ptr) @ 0x0000000015efc18a 23. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001624c1b2 24. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000162f9c70 25. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x00000000162fa55a 26. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc6653 27. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000000fccc4c3 28. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc3d92 29. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fcca080 30. ? @ 0x00007fbc6213eac3 31. ? @ 0x00007fbc621d0850 (version 25.3.6.10636.altinitytest (altinity build)) 2025.07.28 11:52:36.294478 [ 3384 ] {} RefreshTask: test_pjnlliml.c: Refresh failed (attempt 1/3): Code: 60. DB::Exception: Unknown table expression identifier 'test_pjnlliml.src' in scope SELECT * FROM test_pjnlliml.src. (UNKNOWN_TABLE), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x000000000a6a1e2b 4. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:4372: DB::QueryAnalyzer::initializeQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000001404440b 5. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5594: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000140135fb 6. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000140127f9 7. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000014011fce 8. /build/src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000001406ce8a 9. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000014973b42 10. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000001497268d 11. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:205: DB::InterpreterSelectQueryAnalyzer::getSampleBlock(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000014973e7b 12. /build/src/Storages/StorageMaterializedView.cpp:564: DB::StorageMaterializedView::prepareRefresh(bool, std::shared_ptr, std::optional&) const @ 0x0000000015e20cb1 13. /build/src/Storages/MaterializedView/RefreshTask.cpp:649: DB::RefreshTask::executeRefreshUnlocked(bool, int) @ 0x0000000016792338 14. /build/src/Storages/MaterializedView/RefreshTask.cpp:542: DB::RefreshTask::refreshTask() @ 0x000000001678e034 15. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000139630d4 16. /build/src/Core/BackgroundSchedulePool.cpp:308: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001396616a 17. /build/src/Core/BackgroundSchedulePool.cpp:171: void std::__function::__policy_invoker::__call_impl[abi:se190107]::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_1>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_1&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001396690a 18. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc3d92 19. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fcca080 20. ? @ 0x00007fbc6213eac3 21. ? @ 0x00007fbc621d0850 (version 25.3.6.10636.altinitytest (altinity build)) 2025.07.28 11:52:36.392035 [ 3969 ] {} test_13.rmt2 (7f9b740d-015c-470e-8cc6-8ba33be0dc63): auto DB::StorageReplicatedMergeTree::processQueueEntry(ReplicatedMergeTreeQueue::SelectedEntryPtr)::(anonymous class)::operator()(LogEntryPtr &) const: Code: 86. DB::HTTPException: Received error from remote server http://146b4357c08d:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Ftest%2F01165%2Ftest_13%2Frmt%2Freplicas%2F1&part=20250728_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.6.10636.altinitytest (altinity build)) '. (RECEIVED_ERROR_FROM_REMOTE_IO_SERVER), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.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 const&, int&&, String const&, unsigned long&&, String const&) @ 0x000000000feda8d9 4. /build/src/IO/HTTPCommon.cpp:104: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x000000000feda6e2 5. /build/src/IO/HTTPCommon.cpp:93: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x000000000feda537 6. /build/src/IO/ReadWriteBufferFromHTTP.cpp:277: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x000000001184a4c4 7. /build/src/IO/ReadWriteBufferFromHTTP.cpp:285: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x000000001184a615 8. /build/src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x000000001184ae59 9. /build/src/IO/ReadWriteBufferFromHTTP.cpp:472: void std::__function::__policy_invoker::__call_impl[abi:se190107]>(std::__function::__policy_storage const*) @ 0x000000001184cedd 10. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001184858b 11. /build/src/IO/ReadWriteBufferFromHTTP.cpp:465: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x000000001184bf0b 12. /build/src/IO/ReadBuffer.h:60: DB::ReadBuffer::next() @ 0x000000000a148c7b 13. /build/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) @ 0x0000000011849fb2 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]>&)>&, 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&) @ 0x0000000011841980 15. /build/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) @ 0x000000001621208e 16. /build/src/Storages/StorageReplicatedMergeTree.cpp:5228: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl[abi:se190107] const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000015f9a5fe 17. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000015ed8bfd 18. /build/src/Storages/StorageReplicatedMergeTree.cpp:2514: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x0000000015ec9aab 19. /build/src/Storages/StorageReplicatedMergeTree.cpp:2349: DB::StorageReplicatedMergeTree::executeLogEntry(DB::ReplicatedMergeTreeLogEntry&) @ 0x0000000015eba91b 20. /build/src/Storages/StorageReplicatedMergeTree.cpp:3876: bool std::__function::__policy_invoker&)>::__call_impl[abi:se190107])::$_1, bool (std::shared_ptr&)>>(std::__function::__policy_storage const*, std::shared_ptr&) @ 0x0000000015f9837e 21. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000165d6fc3 22. /build/src/Storages/StorageReplicatedMergeTree.cpp:3872: DB::StorageReplicatedMergeTree::processQueueEntry(std::shared_ptr) @ 0x0000000015efc18a 23. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001624c1b2 24. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000162f9c70 25. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x00000000162fa55a 26. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc6653 27. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000000fccc4c3 28. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc3d92 29. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fcca080 30. ? @ 0x00007fbc6213eac3 31. ? @ 0x00007fbc621d0850 (version 25.3.6.10636.altinitytest (altinity build)) 2025.07.28 11:52:36.592931 [ 3669 ] {} RefreshTask: test_pjnlliml.c: Refresh failed (attempt 2/3): Code: 60. DB::Exception: Unknown table expression identifier 'test_pjnlliml.src' in scope SELECT * FROM test_pjnlliml.src. (UNKNOWN_TABLE), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x000000000a6a1e2b 4. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:4372: DB::QueryAnalyzer::initializeQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000001404440b 5. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5594: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000140135fb 6. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000140127f9 7. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000014011fce 8. /build/src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000001406ce8a 9. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000014973b42 10. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000001497268d 11. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:205: DB::InterpreterSelectQueryAnalyzer::getSampleBlock(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000014973e7b 12. /build/src/Storages/StorageMaterializedView.cpp:564: DB::StorageMaterializedView::prepareRefresh(bool, std::shared_ptr, std::optional&) const @ 0x0000000015e20cb1 13. /build/src/Storages/MaterializedView/RefreshTask.cpp:649: DB::RefreshTask::executeRefreshUnlocked(bool, int) @ 0x0000000016792338 14. /build/src/Storages/MaterializedView/RefreshTask.cpp:542: DB::RefreshTask::refreshTask() @ 0x000000001678e034 15. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000139630d4 16. /build/src/Core/BackgroundSchedulePool.cpp:308: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001396616a 17. /build/src/Core/BackgroundSchedulePool.cpp:171: void std::__function::__policy_invoker::__call_impl[abi:se190107]::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_1>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_1&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001396690a 18. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc3d92 19. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fcca080 20. ? @ 0x00007fbc6213eac3 21. ? @ 0x00007fbc621d0850 (version 25.3.6.10636.altinitytest (altinity build)) 2025.07.28 11:52:36.641790 [ 3971 ] {} test_13.rmt2 (7f9b740d-015c-470e-8cc6-8ba33be0dc63): auto DB::StorageReplicatedMergeTree::processQueueEntry(ReplicatedMergeTreeQueue::SelectedEntryPtr)::(anonymous class)::operator()(LogEntryPtr &) const: Code: 86. DB::HTTPException: Received error from remote server http://146b4357c08d:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Ftest%2F01165%2Ftest_13%2Frmt%2Freplicas%2F1&part=20250728_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.6.10636.altinitytest (altinity build)) '. (RECEIVED_ERROR_FROM_REMOTE_IO_SERVER), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.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 const&, int&&, String const&, unsigned long&&, String const&) @ 0x000000000feda8d9 4. /build/src/IO/HTTPCommon.cpp:104: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x000000000feda6e2 5. /build/src/IO/HTTPCommon.cpp:93: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x000000000feda537 6. /build/src/IO/ReadWriteBufferFromHTTP.cpp:277: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x000000001184a4c4 7. /build/src/IO/ReadWriteBufferFromHTTP.cpp:285: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x000000001184a615 8. /build/src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x000000001184ae59 9. /build/src/IO/ReadWriteBufferFromHTTP.cpp:472: void std::__function::__policy_invoker::__call_impl[abi:se190107]>(std::__function::__policy_storage const*) @ 0x000000001184cedd 10. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001184858b 11. /build/src/IO/ReadWriteBufferFromHTTP.cpp:465: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x000000001184bf0b 12. /build/src/IO/ReadBuffer.h:60: DB::ReadBuffer::next() @ 0x000000000a148c7b 13. /build/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) @ 0x0000000011849fb2 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]>&)>&, 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&) @ 0x0000000011841980 15. /build/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) @ 0x000000001621208e 16. /build/src/Storages/StorageReplicatedMergeTree.cpp:5228: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl[abi:se190107] const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000015f9a5fe 17. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000015ed8bfd 18. /build/src/Storages/StorageReplicatedMergeTree.cpp:2514: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x0000000015ec9aab 19. /build/src/Storages/StorageReplicatedMergeTree.cpp:2349: DB::StorageReplicatedMergeTree::executeLogEntry(DB::ReplicatedMergeTreeLogEntry&) @ 0x0000000015eba91b 20. /build/src/Storages/StorageReplicatedMergeTree.cpp:3876: bool std::__function::__policy_invoker&)>::__call_impl[abi:se190107])::$_1, bool (std::shared_ptr&)>>(std::__function::__policy_storage const*, std::shared_ptr&) @ 0x0000000015f9837e 21. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000165d6fc3 22. /build/src/Storages/StorageReplicatedMergeTree.cpp:3872: DB::StorageReplicatedMergeTree::processQueueEntry(std::shared_ptr) @ 0x0000000015efc18a 23. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001624c1b2 24. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000162f9c70 25. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x00000000162fa55a 26. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc6653 27. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000000fccc4c3 28. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc3d92 29. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fcca080 30. ? @ 0x00007fbc6213eac3 31. ? @ 0x00007fbc621d0850 (version 25.3.6.10636.altinitytest (altinity build)) 2025.07.28 11:52:36.686439 [ 3489 ] {} RefreshTask: test_pjnlliml.c: Refresh failed (attempt 3/3): Code: 60. DB::Exception: Unknown table expression identifier 'test_pjnlliml.src' in scope SELECT * FROM test_pjnlliml.src. (UNKNOWN_TABLE), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x000000000a6a1e2b 4. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:4372: DB::QueryAnalyzer::initializeQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000001404440b 5. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5594: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000140135fb 6. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000140127f9 7. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000014011fce 8. /build/src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000001406ce8a 9. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000014973b42 10. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000001497268d 11. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:205: DB::InterpreterSelectQueryAnalyzer::getSampleBlock(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000014973e7b 12. /build/src/Storages/StorageMaterializedView.cpp:564: DB::StorageMaterializedView::prepareRefresh(bool, std::shared_ptr, std::optional&) const @ 0x0000000015e20cb1 13. /build/src/Storages/MaterializedView/RefreshTask.cpp:649: DB::RefreshTask::executeRefreshUnlocked(bool, int) @ 0x0000000016792338 14. /build/src/Storages/MaterializedView/RefreshTask.cpp:542: DB::RefreshTask::refreshTask() @ 0x000000001678e034 15. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000139630d4 16. /build/src/Core/BackgroundSchedulePool.cpp:308: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001396616a 17. /build/src/Core/BackgroundSchedulePool.cpp:171: void std::__function::__policy_invoker::__call_impl[abi:se190107]::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_1>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_1&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001396690a 18. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc3d92 19. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fcca080 20. ? @ 0x00007fbc6213eac3 21. ? @ 0x00007fbc621d0850 (version 25.3.6.10636.altinitytest (altinity build)) 2025.07.28 11:52:37.330900 [ 3961 ] {} test_13.rmt2 (7f9b740d-015c-470e-8cc6-8ba33be0dc63): auto DB::StorageReplicatedMergeTree::processQueueEntry(ReplicatedMergeTreeQueue::SelectedEntryPtr)::(anonymous class)::operator()(LogEntryPtr &) const: Code: 86. DB::HTTPException: Received error from remote server http://146b4357c08d:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Ftest%2F01165%2Ftest_13%2Frmt%2Freplicas%2F1&part=20250728_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.6.10636.altinitytest (altinity build)) '. (RECEIVED_ERROR_FROM_REMOTE_IO_SERVER), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.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 const&, int&&, String const&, unsigned long&&, String const&) @ 0x000000000feda8d9 4. /build/src/IO/HTTPCommon.cpp:104: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x000000000feda6e2 5. /build/src/IO/HTTPCommon.cpp:93: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x000000000feda537 6. /build/src/IO/ReadWriteBufferFromHTTP.cpp:277: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x000000001184a4c4 7. /build/src/IO/ReadWriteBufferFromHTTP.cpp:285: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x000000001184a615 8. /build/src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x000000001184ae59 9. /build/src/IO/ReadWriteBufferFromHTTP.cpp:472: void std::__function::__policy_invoker::__call_impl[abi:se190107]>(std::__function::__policy_storage const*) @ 0x000000001184cedd 10. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001184858b 11. /build/src/IO/ReadWriteBufferFromHTTP.cpp:465: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x000000001184bf0b 12. /build/src/IO/ReadBuffer.h:60: DB::ReadBuffer::next() @ 0x000000000a148c7b 13. /build/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) @ 0x0000000011849fb2 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]>&)>&, 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&) @ 0x0000000011841980 15. /build/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) @ 0x000000001621208e 16. /build/src/Storages/StorageReplicatedMergeTree.cpp:5228: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl[abi:se190107] const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000015f9a5fe 17. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000015ed8bfd 18. /build/src/Storages/StorageReplicatedMergeTree.cpp:2514: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x0000000015ec9aab 19. /build/src/Storages/StorageReplicatedMergeTree.cpp:2349: DB::StorageReplicatedMergeTree::executeLogEntry(DB::ReplicatedMergeTreeLogEntry&) @ 0x0000000015eba91b 20. /build/src/Storages/StorageReplicatedMergeTree.cpp:3876: bool std::__function::__policy_invoker&)>::__call_impl[abi:se190107])::$_1, bool (std::shared_ptr&)>>(std::__function::__policy_storage const*, std::shared_ptr&) @ 0x0000000015f9837e 21. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000165d6fc3 22. /build/src/Storages/StorageReplicatedMergeTree.cpp:3872: DB::StorageReplicatedMergeTree::processQueueEntry(std::shared_ptr) @ 0x0000000015efc18a 23. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001624c1b2 24. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000162f9c70 25. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x00000000162fa55a 26. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc6653 27. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000000fccc4c3 28. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc3d92 29. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fcca080 30. ? @ 0x00007fbc6213eac3 31. ? @ 0x00007fbc621d0850 (version 25.3.6.10636.altinitytest (altinity build)) 2025.07.28 11:52:38.053171 [ 3965 ] {} test_13.rmt2 (7f9b740d-015c-470e-8cc6-8ba33be0dc63): auto DB::StorageReplicatedMergeTree::processQueueEntry(ReplicatedMergeTreeQueue::SelectedEntryPtr)::(anonymous class)::operator()(LogEntryPtr &) const: Code: 86. DB::HTTPException: Received error from remote server http://146b4357c08d:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Ftest%2F01165%2Ftest_13%2Frmt%2Freplicas%2F1&part=20250728_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.6.10636.altinitytest (altinity build)) '. (RECEIVED_ERROR_FROM_REMOTE_IO_SERVER), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.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 const&, int&&, String const&, unsigned long&&, String const&) @ 0x000000000feda8d9 4. /build/src/IO/HTTPCommon.cpp:104: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x000000000feda6e2 5. /build/src/IO/HTTPCommon.cpp:93: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x000000000feda537 6. /build/src/IO/ReadWriteBufferFromHTTP.cpp:277: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x000000001184a4c4 7. /build/src/IO/ReadWriteBufferFromHTTP.cpp:285: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x000000001184a615 8. /build/src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x000000001184ae59 9. /build/src/IO/ReadWriteBufferFromHTTP.cpp:472: void std::__function::__policy_invoker::__call_impl[abi:se190107]>(std::__function::__policy_storage const*) @ 0x000000001184cedd 10. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001184858b 11. /build/src/IO/ReadWriteBufferFromHTTP.cpp:465: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x000000001184bf0b 12. /build/src/IO/ReadBuffer.h:60: DB::ReadBuffer::next() @ 0x000000000a148c7b 13. /build/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) @ 0x0000000011849fb2 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]>&)>&, 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&) @ 0x0000000011841980 15. /build/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) @ 0x000000001621208e 16. /build/src/Storages/StorageReplicatedMergeTree.cpp:5228: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl[abi:se190107] const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000015f9a5fe 17. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000015ed8bfd 18. /build/src/Storages/StorageReplicatedMergeTree.cpp:2514: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x0000000015ec9aab 19. /build/src/Storages/StorageReplicatedMergeTree.cpp:2349: DB::StorageReplicatedMergeTree::executeLogEntry(DB::ReplicatedMergeTreeLogEntry&) @ 0x0000000015eba91b 20. /build/src/Storages/StorageReplicatedMergeTree.cpp:3876: bool std::__function::__policy_invoker&)>::__call_impl[abi:se190107])::$_1, bool (std::shared_ptr&)>>(std::__function::__policy_storage const*, std::shared_ptr&) @ 0x0000000015f9837e 21. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000165d6fc3 22. /build/src/Storages/StorageReplicatedMergeTree.cpp:3872: DB::StorageReplicatedMergeTree::processQueueEntry(std::shared_ptr) @ 0x0000000015efc18a 23. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001624c1b2 24. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000162f9c70 25. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x00000000162fa55a 26. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc6653 27. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000000fccc4c3 28. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc3d92 29. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fcca080 30. ? @ 0x00007fbc6213eac3 31. ? @ 0x00007fbc621d0850 (version 25.3.6.10636.altinitytest (altinity build)) 2025.07.28 11:52:38.473379 [ 3966 ] {} test_13.rmt2 (7f9b740d-015c-470e-8cc6-8ba33be0dc63): auto DB::StorageReplicatedMergeTree::processQueueEntry(ReplicatedMergeTreeQueue::SelectedEntryPtr)::(anonymous class)::operator()(LogEntryPtr &) const: Code: 86. DB::HTTPException: Received error from remote server http://146b4357c08d:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Ftest%2F01165%2Ftest_13%2Frmt%2Freplicas%2F1&part=20250728_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.6.10636.altinitytest (altinity build)) '. (RECEIVED_ERROR_FROM_REMOTE_IO_SERVER), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.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 const&, int&&, String const&, unsigned long&&, String const&) @ 0x000000000feda8d9 4. /build/src/IO/HTTPCommon.cpp:104: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x000000000feda6e2 5. /build/src/IO/HTTPCommon.cpp:93: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x000000000feda537 6. /build/src/IO/ReadWriteBufferFromHTTP.cpp:277: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x000000001184a4c4 7. /build/src/IO/ReadWriteBufferFromHTTP.cpp:285: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x000000001184a615 8. /build/src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x000000001184ae59 9. /build/src/IO/ReadWriteBufferFromHTTP.cpp:472: void std::__function::__policy_invoker::__call_impl[abi:se190107]>(std::__function::__policy_storage const*) @ 0x000000001184cedd 10. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001184858b 11. /build/src/IO/ReadWriteBufferFromHTTP.cpp:465: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x000000001184bf0b 12. /build/src/IO/ReadBuffer.h:60: DB::ReadBuffer::next() @ 0x000000000a148c7b 13. /build/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) @ 0x0000000011849fb2 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]>&)>&, 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&) @ 0x0000000011841980 15. /build/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) @ 0x000000001621208e 16. /build/src/Storages/StorageReplicatedMergeTree.cpp:5228: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl[abi:se190107] const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000015f9a5fe 17. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000015ed8bfd 18. /build/src/Storages/StorageReplicatedMergeTree.cpp:2514: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x0000000015ec9aab 19. /build/src/Storages/StorageReplicatedMergeTree.cpp:2349: DB::StorageReplicatedMergeTree::executeLogEntry(DB::ReplicatedMergeTreeLogEntry&) @ 0x0000000015eba91b 20. /build/src/Storages/StorageReplicatedMergeTree.cpp:3876: bool std::__function::__policy_invoker&)>::__call_impl[abi:se190107])::$_1, bool (std::shared_ptr&)>>(std::__function::__policy_storage const*, std::shared_ptr&) @ 0x0000000015f9837e 21. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000165d6fc3 22. /build/src/Storages/StorageReplicatedMergeTree.cpp:3872: DB::StorageReplicatedMergeTree::processQueueEntry(std::shared_ptr) @ 0x0000000015efc18a 23. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001624c1b2 24. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000162f9c70 25. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x00000000162fa55a 26. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc6653 27. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000000fccc4c3 28. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc3d92 29. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fcca080 30. ? @ 0x00007fbc6213eac3 31. ? @ 0x00007fbc621d0850 (version 25.3.6.10636.altinitytest (altinity build)) 2025.07.28 11:52:39.593721 [ 3971 ] {} test_13.rmt2 (7f9b740d-015c-470e-8cc6-8ba33be0dc63): auto DB::StorageReplicatedMergeTree::processQueueEntry(ReplicatedMergeTreeQueue::SelectedEntryPtr)::(anonymous class)::operator()(LogEntryPtr &) const: Code: 86. DB::HTTPException: Received error from remote server http://146b4357c08d:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Ftest%2F01165%2Ftest_13%2Frmt%2Freplicas%2F1&part=20250728_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.6.10636.altinitytest (altinity build)) '. (RECEIVED_ERROR_FROM_REMOTE_IO_SERVER), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.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 const&, int&&, String const&, unsigned long&&, String const&) @ 0x000000000feda8d9 4. /build/src/IO/HTTPCommon.cpp:104: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x000000000feda6e2 5. /build/src/IO/HTTPCommon.cpp:93: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x000000000feda537 6. /build/src/IO/ReadWriteBufferFromHTTP.cpp:277: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x000000001184a4c4 7. /build/src/IO/ReadWriteBufferFromHTTP.cpp:285: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x000000001184a615 8. /build/src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x000000001184ae59 9. /build/src/IO/ReadWriteBufferFromHTTP.cpp:472: void std::__function::__policy_invoker::__call_impl[abi:se190107]>(std::__function::__policy_storage const*) @ 0x000000001184cedd 10. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001184858b 11. /build/src/IO/ReadWriteBufferFromHTTP.cpp:465: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x000000001184bf0b 12. /build/src/IO/ReadBuffer.h:60: DB::ReadBuffer::next() @ 0x000000000a148c7b 13. /build/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) @ 0x0000000011849fb2 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]>&)>&, 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&) @ 0x0000000011841980 15. /build/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) @ 0x000000001621208e 16. /build/src/Storages/StorageReplicatedMergeTree.cpp:5228: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl[abi:se190107] const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000015f9a5fe 17. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000015ed8bfd 18. /build/src/Storages/StorageReplicatedMergeTree.cpp:2514: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x0000000015ec9aab 19. /build/src/Storages/StorageReplicatedMergeTree.cpp:2349: DB::StorageReplicatedMergeTree::executeLogEntry(DB::ReplicatedMergeTreeLogEntry&) @ 0x0000000015eba91b 20. /build/src/Storages/StorageReplicatedMergeTree.cpp:3876: bool std::__function::__policy_invoker&)>::__call_impl[abi:se190107])::$_1, bool (std::shared_ptr&)>>(std::__function::__policy_storage const*, std::shared_ptr&) @ 0x0000000015f9837e 21. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000165d6fc3 22. /build/src/Storages/StorageReplicatedMergeTree.cpp:3872: DB::StorageReplicatedMergeTree::processQueueEntry(std::shared_ptr) @ 0x0000000015efc18a 23. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001624c1b2 24. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000162f9c70 25. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x00000000162fa55a 26. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc6653 27. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000000fccc4c3 28. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc3d92 29. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fcca080 30. ? @ 0x00007fbc6213eac3 31. ? @ 0x00007fbc621d0850 (version 25.3.6.10636.altinitytest (altinity build)) 2025.07.28 11:52:39.614542 [ 3970 ] {} test_13.alter_table1 (b6d50f9f-3cd1-4fee-aa3e-84cf679f8083): Part /var/lib/clickhouse/store/b6d/b6d50f9f-3cd1-4fee-aa3e-84cf679f8083/detached/all_98_98_0/ is broken and needs manual correction. Reason: Code: 226. DB::Exception: No count.txt in part all_132_132_0. (NO_FILE_IN_DATA_PART), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000a9b78ab 4. /build/src/Storages/MergeTree/IMergeTreeDataPart.cpp:1392: DB::IMergeTreeDataPart::loadRowsCount() @ 0x000000001625d57d 5. /build/src/Storages/MergeTree/IMergeTreeDataPart.cpp:851: DB::IMergeTreeDataPart::loadColumnsChecksumsIndexes(bool, bool) @ 0x000000001625a103 6. /build/src/Storages/StorageReplicatedMergeTree.cpp:2237: DB::StorageReplicatedMergeTree::attachPartHelperFoundValidPart(DB::ReplicatedMergeTreeLogEntry const&) const @ 0x0000000015eb838f 7. /build/src/Storages/StorageReplicatedMergeTree.cpp:2309: DB::StorageReplicatedMergeTree::executeLogEntry(DB::ReplicatedMergeTreeLogEntry&) @ 0x0000000015eb969e 8. /build/src/Storages/StorageReplicatedMergeTree.cpp:3876: bool std::__function::__policy_invoker&)>::__call_impl[abi:se190107])::$_1, bool (std::shared_ptr&)>>(std::__function::__policy_storage const*, std::shared_ptr&) @ 0x0000000015f9837e 9. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000165d6fc3 10. /build/src/Storages/StorageReplicatedMergeTree.cpp:3872: DB::StorageReplicatedMergeTree::processQueueEntry(std::shared_ptr) @ 0x0000000015efc18a 11. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001624c1b2 12. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000162f9c70 13. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x00000000162fa55a 14. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc6653 15. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000000fccc4c3 16. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc3d92 17. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fcca080 18. ? @ 0x00007fbc6213eac3 19. ? @ 0x00007fbc621d0850 (version 25.3.6.10636.altinitytest (altinity build)) 2025.07.28 11:52:40.043766 [ 17270 ] {ce3c23da-848d-47e3-b8d1-bf32b327d3bf} executeQuery: Code: 47. DB::Exception: Unknown expression or function identifier `x` in scope x = 1. Maybe you meant: ['n']. (UNKNOWN_IDENTIFIER) (version 25.3.6.10636.altinitytest (altinity build)) (from [::1]:37018) (comment: 01761_alter_decimal_zookeeper_long.sql) (query 5, line 14) (in query: SELECT * FROM test_alter_decimal ORDER BY n;), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.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&&) @ 0x000000001404b3b9 4. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3771: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000001401b849 5. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3980: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000014018e31 6. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:2925: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000001402fcbd 7. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3838: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000014019a9e 8. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:209: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000001401270e 9. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000014011fce 10. /build/src/Planner/Utils.cpp:458: DB::buildFilterInfo(std::shared_ptr, std::shared_ptr const&, std::shared_ptr&, std::unordered_set, std::equal_to, std::allocator>) @ 0x0000000013fe8bcf 11. /build/src/Planner/PlannerJoinTree.cpp:535: DB::(anonymous namespace)::buildQueryPlanForTableExpression(std::shared_ptr, std::shared_ptr const&, DB::SelectQueryInfo const&, DB::SelectQueryOptions const&, std::shared_ptr&, bool, bool) @ 0x00000000149956d3 12. /build/src/Planner/PlannerJoinTree.cpp:2252: DB::buildJoinTreeQueryPlan(std::shared_ptr const&, DB::SelectQueryInfo const&, DB::SelectQueryOptions&, std::unordered_set, std::equal_to, std::allocator> const&, std::shared_ptr&) @ 0x000000001498e109 13. /build/src/Planner/Planner.cpp:1553: DB::Planner::buildPlanForQueryNode() @ 0x0000000014979dae 14. /build/src/Planner/Planner.cpp:1308: DB::Planner::buildQueryPlanIfNeeded() @ 0x000000001497685c 15. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:255: DB::InterpreterSelectQueryAnalyzer::getQueryPlan() @ 0x000000001497476d 16. /build/src/Interpreters/executeQuery.cpp:1405: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88806 17. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 18. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 19. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 20. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 21. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 22. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 23. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 24. ? @ 0x00007fbc6213eac3 25. ? @ 0x00007fbc621d0850 2025.07.28 11:52:40.057710 [ 17270 ] {} TCPHandler: Code: 47. DB::Exception: Unknown expression or function identifier `x` in scope x = 1. Maybe you meant: ['n']. (UNKNOWN_IDENTIFIER), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.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&&) @ 0x000000001404b3b9 4. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3771: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000001401b849 5. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3980: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000014018e31 6. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:2925: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000001402fcbd 7. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3838: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000014019a9e 8. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:209: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000001401270e 9. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000014011fce 10. /build/src/Planner/Utils.cpp:458: DB::buildFilterInfo(std::shared_ptr, std::shared_ptr const&, std::shared_ptr&, std::unordered_set, std::equal_to, std::allocator>) @ 0x0000000013fe8bcf 11. /build/src/Planner/PlannerJoinTree.cpp:535: DB::(anonymous namespace)::buildQueryPlanForTableExpression(std::shared_ptr, std::shared_ptr const&, DB::SelectQueryInfo const&, DB::SelectQueryOptions const&, std::shared_ptr&, bool, bool) @ 0x00000000149956d3 12. /build/src/Planner/PlannerJoinTree.cpp:2252: DB::buildJoinTreeQueryPlan(std::shared_ptr const&, DB::SelectQueryInfo const&, DB::SelectQueryOptions&, std::unordered_set, std::equal_to, std::allocator> const&, std::shared_ptr&) @ 0x000000001498e109 13. /build/src/Planner/Planner.cpp:1553: DB::Planner::buildPlanForQueryNode() @ 0x0000000014979dae 14. /build/src/Planner/Planner.cpp:1308: DB::Planner::buildQueryPlanIfNeeded() @ 0x000000001497685c 15. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:255: DB::InterpreterSelectQueryAnalyzer::getQueryPlan() @ 0x000000001497476d 16. /build/src/Interpreters/executeQuery.cpp:1405: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88806 17. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 18. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 19. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 20. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 21. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 22. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 23. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 24. ? @ 0x00007fbc6213eac3 25. ? @ 0x00007fbc621d0850 2025.07.28 11:52:40.351455 [ 3964 ] {} test_13.rmt2 (7f9b740d-015c-470e-8cc6-8ba33be0dc63): auto DB::StorageReplicatedMergeTree::processQueueEntry(ReplicatedMergeTreeQueue::SelectedEntryPtr)::(anonymous class)::operator()(LogEntryPtr &) const: Code: 86. DB::HTTPException: Received error from remote server http://146b4357c08d:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Ftest%2F01165%2Ftest_13%2Frmt%2Freplicas%2F1&part=20250728_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.6.10636.altinitytest (altinity build)) '. (RECEIVED_ERROR_FROM_REMOTE_IO_SERVER), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.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 const&, int&&, String const&, unsigned long&&, String const&) @ 0x000000000feda8d9 4. /build/src/IO/HTTPCommon.cpp:104: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x000000000feda6e2 5. /build/src/IO/HTTPCommon.cpp:93: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x000000000feda537 6. /build/src/IO/ReadWriteBufferFromHTTP.cpp:277: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x000000001184a4c4 7. /build/src/IO/ReadWriteBufferFromHTTP.cpp:285: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x000000001184a615 8. /build/src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x000000001184ae59 9. /build/src/IO/ReadWriteBufferFromHTTP.cpp:472: void std::__function::__policy_invoker::__call_impl[abi:se190107]>(std::__function::__policy_storage const*) @ 0x000000001184cedd 10. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001184858b 11. /build/src/IO/ReadWriteBufferFromHTTP.cpp:465: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x000000001184bf0b 12. /build/src/IO/ReadBuffer.h:60: DB::ReadBuffer::next() @ 0x000000000a148c7b 13. /build/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) @ 0x0000000011849fb2 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]>&)>&, 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&) @ 0x0000000011841980 15. /build/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) @ 0x000000001621208e 16. /build/src/Storages/StorageReplicatedMergeTree.cpp:5228: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl[abi:se190107] const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000015f9a5fe 17. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000015ed8bfd 18. /build/src/Storages/StorageReplicatedMergeTree.cpp:2514: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x0000000015ec9aab 19. /build/src/Storages/StorageReplicatedMergeTree.cpp:2349: DB::StorageReplicatedMergeTree::executeLogEntry(DB::ReplicatedMergeTreeLogEntry&) @ 0x0000000015eba91b 20. /build/src/Storages/StorageReplicatedMergeTree.cpp:3876: bool std::__function::__policy_invoker&)>::__call_impl[abi:se190107])::$_1, bool (std::shared_ptr&)>>(std::__function::__policy_storage const*, std::shared_ptr&) @ 0x0000000015f9837e 21. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000165d6fc3 22. /build/src/Storages/StorageReplicatedMergeTree.cpp:3872: DB::StorageReplicatedMergeTree::processQueueEntry(std::shared_ptr) @ 0x0000000015efc18a 23. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001624c1b2 24. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000162f9c70 25. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x00000000162fa55a 26. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc6653 27. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000000fccc4c3 28. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc3d92 29. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fcca080 30. ? @ 0x00007fbc6213eac3 31. ? @ 0x00007fbc621d0850 (version 25.3.6.10636.altinitytest (altinity build)) 2025.07.28 11:52:40.937907 [ 3970 ] {} test_13.rmt2 (7f9b740d-015c-470e-8cc6-8ba33be0dc63): auto DB::StorageReplicatedMergeTree::processQueueEntry(ReplicatedMergeTreeQueue::SelectedEntryPtr)::(anonymous class)::operator()(LogEntryPtr &) const: Code: 86. DB::HTTPException: Received error from remote server http://146b4357c08d:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Ftest%2F01165%2Ftest_13%2Frmt%2Freplicas%2F1&part=20250728_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.6.10636.altinitytest (altinity build)) '. (RECEIVED_ERROR_FROM_REMOTE_IO_SERVER), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.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 const&, int&&, String const&, unsigned long&&, String const&) @ 0x000000000feda8d9 4. /build/src/IO/HTTPCommon.cpp:104: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x000000000feda6e2 5. /build/src/IO/HTTPCommon.cpp:93: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x000000000feda537 6. /build/src/IO/ReadWriteBufferFromHTTP.cpp:277: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x000000001184a4c4 7. /build/src/IO/ReadWriteBufferFromHTTP.cpp:285: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x000000001184a615 8. /build/src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x000000001184ae59 9. /build/src/IO/ReadWriteBufferFromHTTP.cpp:472: void std::__function::__policy_invoker::__call_impl[abi:se190107]>(std::__function::__policy_storage const*) @ 0x000000001184cedd 10. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001184858b 11. /build/src/IO/ReadWriteBufferFromHTTP.cpp:465: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x000000001184bf0b 12. /build/src/IO/ReadBuffer.h:60: DB::ReadBuffer::next() @ 0x000000000a148c7b 13. /build/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) @ 0x0000000011849fb2 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]>&)>&, 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&) @ 0x0000000011841980 15. /build/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) @ 0x000000001621208e 16. /build/src/Storages/StorageReplicatedMergeTree.cpp:5228: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl[abi:se190107] const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000015f9a5fe 17. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000015ed8bfd 18. /build/src/Storages/StorageReplicatedMergeTree.cpp:2514: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x0000000015ec9aab 19. /build/src/Storages/StorageReplicatedMergeTree.cpp:2349: DB::StorageReplicatedMergeTree::executeLogEntry(DB::ReplicatedMergeTreeLogEntry&) @ 0x0000000015eba91b 20. /build/src/Storages/StorageReplicatedMergeTree.cpp:3876: bool std::__function::__policy_invoker&)>::__call_impl[abi:se190107])::$_1, bool (std::shared_ptr&)>>(std::__function::__policy_storage const*, std::shared_ptr&) @ 0x0000000015f9837e 21. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000165d6fc3 22. /build/src/Storages/StorageReplicatedMergeTree.cpp:3872: DB::StorageReplicatedMergeTree::processQueueEntry(std::shared_ptr) @ 0x0000000015efc18a 23. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001624c1b2 24. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000162f9c70 25. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x00000000162fa55a 26. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc6653 27. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000000fccc4c3 28. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc3d92 29. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fcca080 30. ? @ 0x00007fbc6213eac3 31. ? @ 0x00007fbc621d0850 (version 25.3.6.10636.altinitytest (altinity build)) 2025.07.28 11:52:40.973508 [ 17306 ] {e837dd99-f079-43aa-a455-c68383d0a760} executeQuery: Code: 47. DB::Exception: Unknown expression or function identifier `x` in scope x = 1. (UNKNOWN_IDENTIFIER) (version 25.3.6.10636.altinitytest (altinity build)) (from [::1]:37238) (comment: 01413_truncate_without_table_keyword.sql) (query 4, line 7) (in query: SELECT * FROM truncate_test ORDER BY uint8;), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.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&&) @ 0x000000001404b3b9 4. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3771: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000001401b849 5. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3980: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000014018e31 6. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:2925: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000001402fcbd 7. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3838: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000014019a9e 8. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:209: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000001401270e 9. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000014011fce 10. /build/src/Planner/Utils.cpp:458: DB::buildFilterInfo(std::shared_ptr, std::shared_ptr const&, std::shared_ptr&, std::unordered_set, std::equal_to, std::allocator>) @ 0x0000000013fe8bcf 11. /build/src/Planner/PlannerJoinTree.cpp:535: DB::(anonymous namespace)::buildQueryPlanForTableExpression(std::shared_ptr, std::shared_ptr const&, DB::SelectQueryInfo const&, DB::SelectQueryOptions const&, std::shared_ptr&, bool, bool) @ 0x00000000149956d3 12. /build/src/Planner/PlannerJoinTree.cpp:2252: DB::buildJoinTreeQueryPlan(std::shared_ptr const&, DB::SelectQueryInfo const&, DB::SelectQueryOptions&, std::unordered_set, std::equal_to, std::allocator> const&, std::shared_ptr&) @ 0x000000001498e109 13. /build/src/Planner/Planner.cpp:1553: DB::Planner::buildPlanForQueryNode() @ 0x0000000014979dae 14. /build/src/Planner/Planner.cpp:1308: DB::Planner::buildQueryPlanIfNeeded() @ 0x000000001497685c 15. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:255: DB::InterpreterSelectQueryAnalyzer::getQueryPlan() @ 0x000000001497476d 16. /build/src/Interpreters/executeQuery.cpp:1405: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88806 17. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 18. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 19. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 20. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 21. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 22. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 23. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 24. ? @ 0x00007fbc6213eac3 25. ? @ 0x00007fbc621d0850 2025.07.28 11:52:40.988121 [ 17306 ] {} TCPHandler: Code: 47. DB::Exception: Unknown expression or function identifier `x` in scope x = 1. (UNKNOWN_IDENTIFIER), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.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&&) @ 0x000000001404b3b9 4. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3771: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000001401b849 5. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3980: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000014018e31 6. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:2925: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000001402fcbd 7. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3838: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000014019a9e 8. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:209: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000001401270e 9. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000014011fce 10. /build/src/Planner/Utils.cpp:458: DB::buildFilterInfo(std::shared_ptr, std::shared_ptr const&, std::shared_ptr&, std::unordered_set, std::equal_to, std::allocator>) @ 0x0000000013fe8bcf 11. /build/src/Planner/PlannerJoinTree.cpp:535: DB::(anonymous namespace)::buildQueryPlanForTableExpression(std::shared_ptr, std::shared_ptr const&, DB::SelectQueryInfo const&, DB::SelectQueryOptions const&, std::shared_ptr&, bool, bool) @ 0x00000000149956d3 12. /build/src/Planner/PlannerJoinTree.cpp:2252: DB::buildJoinTreeQueryPlan(std::shared_ptr const&, DB::SelectQueryInfo const&, DB::SelectQueryOptions&, std::unordered_set, std::equal_to, std::allocator> const&, std::shared_ptr&) @ 0x000000001498e109 13. /build/src/Planner/Planner.cpp:1553: DB::Planner::buildPlanForQueryNode() @ 0x0000000014979dae 14. /build/src/Planner/Planner.cpp:1308: DB::Planner::buildQueryPlanIfNeeded() @ 0x000000001497685c 15. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:255: DB::InterpreterSelectQueryAnalyzer::getQueryPlan() @ 0x000000001497476d 16. /build/src/Interpreters/executeQuery.cpp:1405: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88806 17. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 18. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 19. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 20. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 21. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 22. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 23. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 24. ? @ 0x00007fbc6213eac3 25. ? @ 0x00007fbc621d0850 2025.07.28 11:52:41.759081 [ 3976 ] {} test_13.rmt2 (7f9b740d-015c-470e-8cc6-8ba33be0dc63): auto DB::StorageReplicatedMergeTree::processQueueEntry(ReplicatedMergeTreeQueue::SelectedEntryPtr)::(anonymous class)::operator()(LogEntryPtr &) const: Code: 86. DB::HTTPException: Received error from remote server http://146b4357c08d:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Ftest%2F01165%2Ftest_13%2Frmt%2Freplicas%2F1&part=20250728_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.6.10636.altinitytest (altinity build)) '. (RECEIVED_ERROR_FROM_REMOTE_IO_SERVER), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.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 const&, int&&, String const&, unsigned long&&, String const&) @ 0x000000000feda8d9 4. /build/src/IO/HTTPCommon.cpp:104: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x000000000feda6e2 5. /build/src/IO/HTTPCommon.cpp:93: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x000000000feda537 6. /build/src/IO/ReadWriteBufferFromHTTP.cpp:277: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x000000001184a4c4 7. /build/src/IO/ReadWriteBufferFromHTTP.cpp:285: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x000000001184a615 8. /build/src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x000000001184ae59 9. /build/src/IO/ReadWriteBufferFromHTTP.cpp:472: void std::__function::__policy_invoker::__call_impl[abi:se190107]>(std::__function::__policy_storage const*) @ 0x000000001184cedd 10. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001184858b 11. /build/src/IO/ReadWriteBufferFromHTTP.cpp:465: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x000000001184bf0b 12. /build/src/IO/ReadBuffer.h:60: DB::ReadBuffer::next() @ 0x000000000a148c7b 13. /build/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) @ 0x0000000011849fb2 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]>&)>&, 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&) @ 0x0000000011841980 15. /build/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) @ 0x000000001621208e 16. /build/src/Storages/StorageReplicatedMergeTree.cpp:5228: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl[abi:se190107] const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000015f9a5fe 17. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000015ed8bfd 18. /build/src/Storages/StorageReplicatedMergeTree.cpp:2514: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x0000000015ec9aab 19. /build/src/Storages/StorageReplicatedMergeTree.cpp:2349: DB::StorageReplicatedMergeTree::executeLogEntry(DB::ReplicatedMergeTreeLogEntry&) @ 0x0000000015eba91b 20. /build/src/Storages/StorageReplicatedMergeTree.cpp:3876: bool std::__function::__policy_invoker&)>::__call_impl[abi:se190107])::$_1, bool (std::shared_ptr&)>>(std::__function::__policy_storage const*, std::shared_ptr&) @ 0x0000000015f9837e 21. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000165d6fc3 22. /build/src/Storages/StorageReplicatedMergeTree.cpp:3872: DB::StorageReplicatedMergeTree::processQueueEntry(std::shared_ptr) @ 0x0000000015efc18a 23. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001624c1b2 24. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000162f9c70 25. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x00000000162fa55a 26. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc6653 27. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000000fccc4c3 28. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc3d92 29. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fcca080 30. ? @ 0x00007fbc6213eac3 31. ? @ 0x00007fbc621d0850 (version 25.3.6.10636.altinitytest (altinity build)) 2025.07.28 11:52:42.699189 [ 3960 ] {} test_13.rmt2 (7f9b740d-015c-470e-8cc6-8ba33be0dc63): auto DB::StorageReplicatedMergeTree::processQueueEntry(ReplicatedMergeTreeQueue::SelectedEntryPtr)::(anonymous class)::operator()(LogEntryPtr &) const: Code: 86. DB::HTTPException: Received error from remote server http://146b4357c08d:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Ftest%2F01165%2Ftest_13%2Frmt%2Freplicas%2F1&part=20250728_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.6.10636.altinitytest (altinity build)) '. (RECEIVED_ERROR_FROM_REMOTE_IO_SERVER), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.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 const&, int&&, String const&, unsigned long&&, String const&) @ 0x000000000feda8d9 4. /build/src/IO/HTTPCommon.cpp:104: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x000000000feda6e2 5. /build/src/IO/HTTPCommon.cpp:93: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x000000000feda537 6. /build/src/IO/ReadWriteBufferFromHTTP.cpp:277: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x000000001184a4c4 7. /build/src/IO/ReadWriteBufferFromHTTP.cpp:285: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x000000001184a615 8. /build/src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x000000001184ae59 9. /build/src/IO/ReadWriteBufferFromHTTP.cpp:472: void std::__function::__policy_invoker::__call_impl[abi:se190107]>(std::__function::__policy_storage const*) @ 0x000000001184cedd 10. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001184858b 11. /build/src/IO/ReadWriteBufferFromHTTP.cpp:465: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x000000001184bf0b 12. /build/src/IO/ReadBuffer.h:60: DB::ReadBuffer::next() @ 0x000000000a148c7b 13. /build/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) @ 0x0000000011849fb2 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]>&)>&, 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&) @ 0x0000000011841980 15. /build/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) @ 0x000000001621208e 16. /build/src/Storages/StorageReplicatedMergeTree.cpp:5228: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl[abi:se190107] const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000015f9a5fe 17. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000015ed8bfd 18. /build/src/Storages/StorageReplicatedMergeTree.cpp:2514: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x0000000015ec9aab 19. /build/src/Storages/StorageReplicatedMergeTree.cpp:2349: DB::StorageReplicatedMergeTree::executeLogEntry(DB::ReplicatedMergeTreeLogEntry&) @ 0x0000000015eba91b 20. /build/src/Storages/StorageReplicatedMergeTree.cpp:3876: bool std::__function::__policy_invoker&)>::__call_impl[abi:se190107])::$_1, bool (std::shared_ptr&)>>(std::__function::__policy_storage const*, std::shared_ptr&) @ 0x0000000015f9837e 21. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000165d6fc3 22. /build/src/Storages/StorageReplicatedMergeTree.cpp:3872: DB::StorageReplicatedMergeTree::processQueueEntry(std::shared_ptr) @ 0x0000000015efc18a 23. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001624c1b2 24. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000162f9c70 25. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x00000000162fa55a 26. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc6653 27. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000000fccc4c3 28. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc3d92 29. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fcca080 30. ? @ 0x00007fbc6213eac3 31. ? @ 0x00007fbc621d0850 (version 25.3.6.10636.altinitytest (altinity build)) 2025.07.28 11:52:43.249538 [ 4581 ] {577e1a7a-3b72-44fd-a39d-2c53ef4c42ad} executeQuery: Code: 47. DB::Exception: Unknown expression or function identifier `x` in scope x = 1. (UNKNOWN_IDENTIFIER) (version 25.3.6.10636.altinitytest (altinity build)) (from [::1]:34434) (comment: 00858_issue_4756.sql) (query 13, line 18) (in query: select distinct(distr1.id) from distr1 where distr1.id in ( select distr1.id from distr1 join distr2 on distr1.id = distr2.id where distr1.id > 0 );), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.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&&) @ 0x000000001404b3b9 4. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3771: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000001401b849 5. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3980: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000014018e31 6. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:2925: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000001402fcbd 7. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3838: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000014019a9e 8. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:209: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000001401270e 9. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000014011fce 10. /build/src/Planner/Utils.cpp:458: DB::buildFilterInfo(std::shared_ptr, std::shared_ptr const&, std::shared_ptr&, std::unordered_set, std::equal_to, std::allocator>) @ 0x0000000013fe8bcf 11. /build/src/Planner/PlannerJoinTree.cpp:535: DB::(anonymous namespace)::buildQueryPlanForTableExpression(std::shared_ptr, std::shared_ptr const&, DB::SelectQueryInfo const&, DB::SelectQueryOptions const&, std::shared_ptr&, bool, bool) @ 0x00000000149956d3 12. /build/src/Planner/PlannerJoinTree.cpp:2252: DB::buildJoinTreeQueryPlan(std::shared_ptr const&, DB::SelectQueryInfo const&, DB::SelectQueryOptions&, std::unordered_set, std::equal_to, std::allocator> const&, std::shared_ptr&) @ 0x000000001498e109 13. /build/src/Planner/Planner.cpp:1553: DB::Planner::buildPlanForQueryNode() @ 0x0000000014979dae 14. /build/src/Planner/Planner.cpp:1308: DB::Planner::buildQueryPlanIfNeeded() @ 0x000000001497685c 15. /build/src/Planner/Planner.cpp:243: DB::Planner::Planner(std::shared_ptr const&, DB::SelectQueryOptions&) @ 0x0000000014975600 16. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:169: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000014972706 17. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000014974d24 18. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001492924b 19. /build/src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88641 20. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 21. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 22. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 23. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 24. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 25. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 26. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 27. ? @ 0x00007fbc6213eac3 28. ? @ 0x00007fbc621d0850 2025.07.28 11:52:43.282826 [ 4581 ] {} TCPHandler: Code: 47. DB::Exception: Unknown expression or function identifier `x` in scope x = 1. (UNKNOWN_IDENTIFIER), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.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&&) @ 0x000000001404b3b9 4. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3771: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000001401b849 5. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3980: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000014018e31 6. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:2925: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000001402fcbd 7. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3838: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000014019a9e 8. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:209: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000001401270e 9. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000014011fce 10. /build/src/Planner/Utils.cpp:458: DB::buildFilterInfo(std::shared_ptr, std::shared_ptr const&, std::shared_ptr&, std::unordered_set, std::equal_to, std::allocator>) @ 0x0000000013fe8bcf 11. /build/src/Planner/PlannerJoinTree.cpp:535: DB::(anonymous namespace)::buildQueryPlanForTableExpression(std::shared_ptr, std::shared_ptr const&, DB::SelectQueryInfo const&, DB::SelectQueryOptions const&, std::shared_ptr&, bool, bool) @ 0x00000000149956d3 12. /build/src/Planner/PlannerJoinTree.cpp:2252: DB::buildJoinTreeQueryPlan(std::shared_ptr const&, DB::SelectQueryInfo const&, DB::SelectQueryOptions&, std::unordered_set, std::equal_to, std::allocator> const&, std::shared_ptr&) @ 0x000000001498e109 13. /build/src/Planner/Planner.cpp:1553: DB::Planner::buildPlanForQueryNode() @ 0x0000000014979dae 14. /build/src/Planner/Planner.cpp:1308: DB::Planner::buildQueryPlanIfNeeded() @ 0x000000001497685c 15. /build/src/Planner/Planner.cpp:243: DB::Planner::Planner(std::shared_ptr const&, DB::SelectQueryOptions&) @ 0x0000000014975600 16. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:169: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000014972706 17. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000014974d24 18. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001492924b 19. /build/src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88641 20. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 21. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 22. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 23. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 24. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 25. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 26. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 27. ? @ 0x00007fbc6213eac3 28. ? @ 0x00007fbc621d0850 2025.07.28 11:52:43.432460 [ 3963 ] {} test_13.rmt2 (7f9b740d-015c-470e-8cc6-8ba33be0dc63): auto DB::StorageReplicatedMergeTree::processQueueEntry(ReplicatedMergeTreeQueue::SelectedEntryPtr)::(anonymous class)::operator()(LogEntryPtr &) const: Code: 86. DB::HTTPException: Received error from remote server http://146b4357c08d:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Ftest%2F01165%2Ftest_13%2Frmt%2Freplicas%2F1&part=20250728_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.6.10636.altinitytest (altinity build)) '. (RECEIVED_ERROR_FROM_REMOTE_IO_SERVER), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.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 const&, int&&, String const&, unsigned long&&, String const&) @ 0x000000000feda8d9 4. /build/src/IO/HTTPCommon.cpp:104: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x000000000feda6e2 5. /build/src/IO/HTTPCommon.cpp:93: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x000000000feda537 6. /build/src/IO/ReadWriteBufferFromHTTP.cpp:277: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x000000001184a4c4 7. /build/src/IO/ReadWriteBufferFromHTTP.cpp:285: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x000000001184a615 8. /build/src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x000000001184ae59 9. /build/src/IO/ReadWriteBufferFromHTTP.cpp:472: void std::__function::__policy_invoker::__call_impl[abi:se190107]>(std::__function::__policy_storage const*) @ 0x000000001184cedd 10. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001184858b 11. /build/src/IO/ReadWriteBufferFromHTTP.cpp:465: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x000000001184bf0b 12. /build/src/IO/ReadBuffer.h:60: DB::ReadBuffer::next() @ 0x000000000a148c7b 13. /build/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) @ 0x0000000011849fb2 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]>&)>&, 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&) @ 0x0000000011841980 15. /build/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) @ 0x000000001621208e 16. /build/src/Storages/StorageReplicatedMergeTree.cpp:5228: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl[abi:se190107] const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000015f9a5fe 17. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000015ed8bfd 18. /build/src/Storages/StorageReplicatedMergeTree.cpp:2514: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x0000000015ec9aab 19. /build/src/Storages/StorageReplicatedMergeTree.cpp:2349: DB::StorageReplicatedMergeTree::executeLogEntry(DB::ReplicatedMergeTreeLogEntry&) @ 0x0000000015eba91b 20. /build/src/Storages/StorageReplicatedMergeTree.cpp:3876: bool std::__function::__policy_invoker&)>::__call_impl[abi:se190107])::$_1, bool (std::shared_ptr&)>>(std::__function::__policy_storage const*, std::shared_ptr&) @ 0x0000000015f9837e 21. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000165d6fc3 22. /build/src/Storages/StorageReplicatedMergeTree.cpp:3872: DB::StorageReplicatedMergeTree::processQueueEntry(std::shared_ptr) @ 0x0000000015efc18a 23. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001624c1b2 24. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000162f9c70 25. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x00000000162fa55a 26. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc6653 27. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000000fccc4c3 28. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc3d92 29. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fcca080 30. ? @ 0x00007fbc6213eac3 31. ? @ 0x00007fbc621d0850 (version 25.3.6.10636.altinitytest (altinity build)) 2025.07.28 11:52:43.911294 [ 3965 ] {} test_13.rmt2 (7f9b740d-015c-470e-8cc6-8ba33be0dc63): auto DB::StorageReplicatedMergeTree::processQueueEntry(ReplicatedMergeTreeQueue::SelectedEntryPtr)::(anonymous class)::operator()(LogEntryPtr &) const: Code: 86. DB::HTTPException: Received error from remote server http://146b4357c08d:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Ftest%2F01165%2Ftest_13%2Frmt%2Freplicas%2F1&part=20250728_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.6.10636.altinitytest (altinity build)) '. (RECEIVED_ERROR_FROM_REMOTE_IO_SERVER), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.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 const&, int&&, String const&, unsigned long&&, String const&) @ 0x000000000feda8d9 4. /build/src/IO/HTTPCommon.cpp:104: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x000000000feda6e2 5. /build/src/IO/HTTPCommon.cpp:93: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x000000000feda537 6. /build/src/IO/ReadWriteBufferFromHTTP.cpp:277: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x000000001184a4c4 7. /build/src/IO/ReadWriteBufferFromHTTP.cpp:285: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x000000001184a615 8. /build/src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x000000001184ae59 9. /build/src/IO/ReadWriteBufferFromHTTP.cpp:472: void std::__function::__policy_invoker::__call_impl[abi:se190107]>(std::__function::__policy_storage const*) @ 0x000000001184cedd 10. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001184858b 11. /build/src/IO/ReadWriteBufferFromHTTP.cpp:465: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x000000001184bf0b 12. /build/src/IO/ReadBuffer.h:60: DB::ReadBuffer::next() @ 0x000000000a148c7b 13. /build/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) @ 0x0000000011849fb2 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]>&)>&, 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&) @ 0x0000000011841980 15. /build/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) @ 0x000000001621208e 16. /build/src/Storages/StorageReplicatedMergeTree.cpp:5228: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl[abi:se190107] const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000015f9a5fe 17. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000015ed8bfd 18. /build/src/Storages/StorageReplicatedMergeTree.cpp:2514: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x0000000015ec9aab 19. /build/src/Storages/StorageReplicatedMergeTree.cpp:2349: DB::StorageReplicatedMergeTree::executeLogEntry(DB::ReplicatedMergeTreeLogEntry&) @ 0x0000000015eba91b 20. /build/src/Storages/StorageReplicatedMergeTree.cpp:3876: bool std::__function::__policy_invoker&)>::__call_impl[abi:se190107])::$_1, bool (std::shared_ptr&)>>(std::__function::__policy_storage const*, std::shared_ptr&) @ 0x0000000015f9837e 21. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000165d6fc3 22. /build/src/Storages/StorageReplicatedMergeTree.cpp:3872: DB::StorageReplicatedMergeTree::processQueueEntry(std::shared_ptr) @ 0x0000000015efc18a 23. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001624c1b2 24. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000162f9c70 25. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x00000000162fa55a 26. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc6653 27. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000000fccc4c3 28. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc3d92 29. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fcca080 30. ? @ 0x00007fbc6213eac3 31. ? @ 0x00007fbc621d0850 (version 25.3.6.10636.altinitytest (altinity build)) 2025.07.28 11:52:44.299522 [ 17210 ] {d1e6c408-83d9-46cc-8bbf-657a1ec84104} 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.6.10636.altinitytest (altinity build)) (from [::1]:34616) (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. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x000000000a06b56b 4. /build/src/Functions/toFixedString.h:52: DB::FunctionToFixedString::getReturnTypeImpl(std::vector> const&) const @ 0x000000000e84ff25 5. /build/src/Functions/IFunction.cpp:645: DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x0000000012d96b0c 6. /build/src/Functions/IFunction.cpp:577: DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x0000000012d9669c 7. /build/src/Functions/IFunction.cpp:606: DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x0000000012d96edc 8. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3544: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000014033cc9 9. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3838: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000014019a9e 10. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:254: DB::QueryAnalyzer::resolveConstantExpression(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000001401fd4b 11. /build/src/Interpreters/evaluateConstantExpression.cpp:115: DB::evaluateConstantExpressionImpl(std::shared_ptr const&, std::shared_ptr const&, bool) @ 0x0000000014c67ee1 12. /build/src/Interpreters/evaluateConstantExpression.cpp:196: DB::evaluateConstantExpression(std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000014c69cb9 13. /build/src/Interpreters/evaluateConstantExpression.cpp:207: DB::evaluateConstantExpressionAsLiteral(std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000014c69e42 14. /build/src/Interpreters/evaluateConstantExpression.cpp:215: DB::evaluateConstantExpressionOrIdentifierAsLiteral(std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000014c69f2a 15. /build/src/TableFunctions/TableFunctionFormat.cpp:81: DB::(anonymous namespace)::TableFunctionFormat::parseArguments(std::shared_ptr const&, std::shared_ptr) @ 0x0000000011858d18 16. /build/src/TableFunctions/TableFunctionFactory.cpp:53: DB::TableFunctionFactory::get(std::shared_ptr const&, std::shared_ptr) const @ 0x00000000131ef757 17. /build/src/Interpreters/InterpreterDescribeQuery.cpp:157: DB::InterpreterDescribeQuery::fillColumnsFromTableFunction(DB::ASTTableExpression const&) @ 0x0000000014cddb18 18. /build/src/Interpreters/InterpreterDescribeQuery.cpp:102: DB::InterpreterDescribeQuery::execute() @ 0x0000000014cdce78 19. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88dc9 20. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 21. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 22. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 23. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 24. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 25. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 26. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 27. ? @ 0x00007fbc6213eac3 28. ? @ 0x00007fbc621d0850 2025.07.28 11:52:44.364162 [ 17210 ] {} 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. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x000000000a06b56b 4. /build/src/Functions/toFixedString.h:52: DB::FunctionToFixedString::getReturnTypeImpl(std::vector> const&) const @ 0x000000000e84ff25 5. /build/src/Functions/IFunction.cpp:645: DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x0000000012d96b0c 6. /build/src/Functions/IFunction.cpp:577: DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x0000000012d9669c 7. /build/src/Functions/IFunction.cpp:606: DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x0000000012d96edc 8. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3544: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000014033cc9 9. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3838: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000014019a9e 10. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:254: DB::QueryAnalyzer::resolveConstantExpression(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000001401fd4b 11. /build/src/Interpreters/evaluateConstantExpression.cpp:115: DB::evaluateConstantExpressionImpl(std::shared_ptr const&, std::shared_ptr const&, bool) @ 0x0000000014c67ee1 12. /build/src/Interpreters/evaluateConstantExpression.cpp:196: DB::evaluateConstantExpression(std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000014c69cb9 13. /build/src/Interpreters/evaluateConstantExpression.cpp:207: DB::evaluateConstantExpressionAsLiteral(std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000014c69e42 14. /build/src/Interpreters/evaluateConstantExpression.cpp:215: DB::evaluateConstantExpressionOrIdentifierAsLiteral(std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000014c69f2a 15. /build/src/TableFunctions/TableFunctionFormat.cpp:81: DB::(anonymous namespace)::TableFunctionFormat::parseArguments(std::shared_ptr const&, std::shared_ptr) @ 0x0000000011858d18 16. /build/src/TableFunctions/TableFunctionFactory.cpp:53: DB::TableFunctionFactory::get(std::shared_ptr const&, std::shared_ptr) const @ 0x00000000131ef757 17. /build/src/Interpreters/InterpreterDescribeQuery.cpp:157: DB::InterpreterDescribeQuery::fillColumnsFromTableFunction(DB::ASTTableExpression const&) @ 0x0000000014cddb18 18. /build/src/Interpreters/InterpreterDescribeQuery.cpp:102: DB::InterpreterDescribeQuery::execute() @ 0x0000000014cdce78 19. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88dc9 20. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 21. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 22. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 23. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 24. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 25. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 26. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 27. ? @ 0x00007fbc6213eac3 28. ? @ 0x00007fbc621d0850 2025.07.28 11:52:44.492150 [ 3970 ] {} test_13.rmt2 (7f9b740d-015c-470e-8cc6-8ba33be0dc63): auto DB::StorageReplicatedMergeTree::processQueueEntry(ReplicatedMergeTreeQueue::SelectedEntryPtr)::(anonymous class)::operator()(LogEntryPtr &) const: Code: 86. DB::HTTPException: Received error from remote server http://146b4357c08d:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Ftest%2F01165%2Ftest_13%2Frmt%2Freplicas%2F1&part=20250728_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.6.10636.altinitytest (altinity build)) '. (RECEIVED_ERROR_FROM_REMOTE_IO_SERVER), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.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 const&, int&&, String const&, unsigned long&&, String const&) @ 0x000000000feda8d9 4. /build/src/IO/HTTPCommon.cpp:104: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x000000000feda6e2 5. /build/src/IO/HTTPCommon.cpp:93: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x000000000feda537 6. /build/src/IO/ReadWriteBufferFromHTTP.cpp:277: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x000000001184a4c4 7. /build/src/IO/ReadWriteBufferFromHTTP.cpp:285: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x000000001184a615 8. /build/src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x000000001184ae59 9. /build/src/IO/ReadWriteBufferFromHTTP.cpp:472: void std::__function::__policy_invoker::__call_impl[abi:se190107]>(std::__function::__policy_storage const*) @ 0x000000001184cedd 10. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001184858b 11. /build/src/IO/ReadWriteBufferFromHTTP.cpp:465: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x000000001184bf0b 12. /build/src/IO/ReadBuffer.h:60: DB::ReadBuffer::next() @ 0x000000000a148c7b 13. /build/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) @ 0x0000000011849fb2 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]>&)>&, 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&) @ 0x0000000011841980 15. /build/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) @ 0x000000001621208e 16. /build/src/Storages/StorageReplicatedMergeTree.cpp:5228: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl[abi:se190107] const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000015f9a5fe 17. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000015ed8bfd 18. /build/src/Storages/StorageReplicatedMergeTree.cpp:2514: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x0000000015ec9aab 19. /build/src/Storages/StorageReplicatedMergeTree.cpp:2349: DB::StorageReplicatedMergeTree::executeLogEntry(DB::ReplicatedMergeTreeLogEntry&) @ 0x0000000015eba91b 20. /build/src/Storages/StorageReplicatedMergeTree.cpp:3876: bool std::__function::__policy_invoker&)>::__call_impl[abi:se190107])::$_1, bool (std::shared_ptr&)>>(std::__function::__policy_storage const*, std::shared_ptr&) @ 0x0000000015f9837e 21. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000165d6fc3 22. /build/src/Storages/StorageReplicatedMergeTree.cpp:3872: DB::StorageReplicatedMergeTree::processQueueEntry(std::shared_ptr) @ 0x0000000015efc18a 23. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001624c1b2 24. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000162f9c70 25. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x00000000162fa55a 26. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc6653 27. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000000fccc4c3 28. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc3d92 29. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fcca080 30. ? @ 0x00007fbc6213eac3 31. ? @ 0x00007fbc621d0850 (version 25.3.6.10636.altinitytest (altinity build)) 2025.07.28 11:52:44.627381 [ 11826 ] {5e6e7d95-e879-42bb-b85a-b78c7915ac86} executeQuery: Code: 47. DB::Exception: Unknown expression or function identifier `x` in scope x = 1. Maybe you meant: ['a']. (UNKNOWN_IDENTIFIER) (version 25.3.6.10636.altinitytest (altinity build)) (from [::1]:34652) (comment: 01671_merge_join_and_constants.sql) (query 10, line 15) (in query: SELECT * FROM table1 AS t1 ALL LEFT JOIN (SELECT *, '0.10', c, d AS b FROM table2) AS t2 USING (a, b) ORDER BY d, t1.a ASC FORMAT PrettyCompact settings max_rows_in_join = 1;), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.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&&) @ 0x000000001404b3b9 4. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3771: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000001401b849 5. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3980: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000014018e31 6. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:2925: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000001402fcbd 7. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3838: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000014019a9e 8. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:209: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000001401270e 9. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000014011fce 10. /build/src/Planner/Utils.cpp:458: DB::buildFilterInfo(std::shared_ptr, std::shared_ptr const&, std::shared_ptr&, std::unordered_set, std::equal_to, std::allocator>) @ 0x0000000013fe8bcf 11. /build/src/Planner/PlannerJoinTree.cpp:535: DB::(anonymous namespace)::buildQueryPlanForTableExpression(std::shared_ptr, std::shared_ptr const&, DB::SelectQueryInfo const&, DB::SelectQueryOptions const&, std::shared_ptr&, bool, bool) @ 0x00000000149956d3 12. /build/src/Planner/PlannerJoinTree.cpp:2252: DB::buildJoinTreeQueryPlan(std::shared_ptr const&, DB::SelectQueryInfo const&, DB::SelectQueryOptions&, std::unordered_set, std::equal_to, std::allocator> const&, std::shared_ptr&) @ 0x000000001498e109 13. /build/src/Planner/Planner.cpp:1553: DB::Planner::buildPlanForQueryNode() @ 0x0000000014979dae 14. /build/src/Planner/Planner.cpp:1308: DB::Planner::buildQueryPlanIfNeeded() @ 0x000000001497685c 15. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:255: DB::InterpreterSelectQueryAnalyzer::getQueryPlan() @ 0x000000001497476d 16. /build/src/Interpreters/executeQuery.cpp:1405: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88806 17. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 18. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 19. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 20. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 21. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 22. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 23. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 24. ? @ 0x00007fbc6213eac3 25. ? @ 0x00007fbc621d0850 2025.07.28 11:52:44.641683 [ 11826 ] {} TCPHandler: Code: 47. DB::Exception: Unknown expression or function identifier `x` in scope x = 1. Maybe you meant: ['a']. (UNKNOWN_IDENTIFIER), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.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&&) @ 0x000000001404b3b9 4. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3771: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000001401b849 5. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3980: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000014018e31 6. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:2925: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000001402fcbd 7. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3838: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000014019a9e 8. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:209: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000001401270e 9. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000014011fce 10. /build/src/Planner/Utils.cpp:458: DB::buildFilterInfo(std::shared_ptr, std::shared_ptr const&, std::shared_ptr&, std::unordered_set, std::equal_to, std::allocator>) @ 0x0000000013fe8bcf 11. /build/src/Planner/PlannerJoinTree.cpp:535: DB::(anonymous namespace)::buildQueryPlanForTableExpression(std::shared_ptr, std::shared_ptr const&, DB::SelectQueryInfo const&, DB::SelectQueryOptions const&, std::shared_ptr&, bool, bool) @ 0x00000000149956d3 12. /build/src/Planner/PlannerJoinTree.cpp:2252: DB::buildJoinTreeQueryPlan(std::shared_ptr const&, DB::SelectQueryInfo const&, DB::SelectQueryOptions&, std::unordered_set, std::equal_to, std::allocator> const&, std::shared_ptr&) @ 0x000000001498e109 13. /build/src/Planner/Planner.cpp:1553: DB::Planner::buildPlanForQueryNode() @ 0x0000000014979dae 14. /build/src/Planner/Planner.cpp:1308: DB::Planner::buildQueryPlanIfNeeded() @ 0x000000001497685c 15. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:255: DB::InterpreterSelectQueryAnalyzer::getQueryPlan() @ 0x000000001497476d 16. /build/src/Interpreters/executeQuery.cpp:1405: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88806 17. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 18. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 19. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 20. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 21. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 22. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 23. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 24. ? @ 0x00007fbc6213eac3 25. ? @ 0x00007fbc621d0850 2025.07.28 11:52:45.211800 [ 3961 ] {} test_13.rmt2 (7f9b740d-015c-470e-8cc6-8ba33be0dc63): auto DB::StorageReplicatedMergeTree::processQueueEntry(ReplicatedMergeTreeQueue::SelectedEntryPtr)::(anonymous class)::operator()(LogEntryPtr &) const: Code: 86. DB::HTTPException: Received error from remote server http://146b4357c08d:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Ftest%2F01165%2Ftest_13%2Frmt%2Freplicas%2F1&part=20250728_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.6.10636.altinitytest (altinity build)) '. (RECEIVED_ERROR_FROM_REMOTE_IO_SERVER), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.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 const&, int&&, String const&, unsigned long&&, String const&) @ 0x000000000feda8d9 4. /build/src/IO/HTTPCommon.cpp:104: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x000000000feda6e2 5. /build/src/IO/HTTPCommon.cpp:93: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x000000000feda537 6. /build/src/IO/ReadWriteBufferFromHTTP.cpp:277: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x000000001184a4c4 7. /build/src/IO/ReadWriteBufferFromHTTP.cpp:285: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x000000001184a615 8. /build/src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x000000001184ae59 9. /build/src/IO/ReadWriteBufferFromHTTP.cpp:472: void std::__function::__policy_invoker::__call_impl[abi:se190107]>(std::__function::__policy_storage const*) @ 0x000000001184cedd 10. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001184858b 11. /build/src/IO/ReadWriteBufferFromHTTP.cpp:465: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x000000001184bf0b 12. /build/src/IO/ReadBuffer.h:60: DB::ReadBuffer::next() @ 0x000000000a148c7b 13. /build/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) @ 0x0000000011849fb2 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]>&)>&, 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&) @ 0x0000000011841980 15. /build/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) @ 0x000000001621208e 16. /build/src/Storages/StorageReplicatedMergeTree.cpp:5228: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl[abi:se190107] const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000015f9a5fe 17. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000015ed8bfd 18. /build/src/Storages/StorageReplicatedMergeTree.cpp:2514: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x0000000015ec9aab 19. /build/src/Storages/StorageReplicatedMergeTree.cpp:2349: DB::StorageReplicatedMergeTree::executeLogEntry(DB::ReplicatedMergeTreeLogEntry&) @ 0x0000000015eba91b 20. /build/src/Storages/StorageReplicatedMergeTree.cpp:3876: bool std::__function::__policy_invoker&)>::__call_impl[abi:se190107])::$_1, bool (std::shared_ptr&)>>(std::__function::__policy_storage const*, std::shared_ptr&) @ 0x0000000015f9837e 21. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000165d6fc3 22. /build/src/Storages/StorageReplicatedMergeTree.cpp:3872: DB::StorageReplicatedMergeTree::processQueueEntry(std::shared_ptr) @ 0x0000000015efc18a 23. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001624c1b2 24. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000162f9c70 25. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x00000000162fa55a 26. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc6653 27. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000000fccc4c3 28. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc3d92 29. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fcca080 30. ? @ 0x00007fbc6213eac3 31. ? @ 0x00007fbc621d0850 (version 25.3.6.10636.altinitytest (altinity build)) 2025.07.28 11:52:45.440595 [ 3972 ] {} test_13.rmt2 (7f9b740d-015c-470e-8cc6-8ba33be0dc63): auto DB::StorageReplicatedMergeTree::processQueueEntry(ReplicatedMergeTreeQueue::SelectedEntryPtr)::(anonymous class)::operator()(LogEntryPtr &) const: Code: 86. DB::HTTPException: Received error from remote server http://146b4357c08d:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Ftest%2F01165%2Ftest_13%2Frmt%2Freplicas%2F1&part=20250728_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.6.10636.altinitytest (altinity build)) '. (RECEIVED_ERROR_FROM_REMOTE_IO_SERVER), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.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 const&, int&&, String const&, unsigned long&&, String const&) @ 0x000000000feda8d9 4. /build/src/IO/HTTPCommon.cpp:104: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x000000000feda6e2 5. /build/src/IO/HTTPCommon.cpp:93: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x000000000feda537 6. /build/src/IO/ReadWriteBufferFromHTTP.cpp:277: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x000000001184a4c4 7. /build/src/IO/ReadWriteBufferFromHTTP.cpp:285: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x000000001184a615 8. /build/src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x000000001184ae59 9. /build/src/IO/ReadWriteBufferFromHTTP.cpp:472: void std::__function::__policy_invoker::__call_impl[abi:se190107]>(std::__function::__policy_storage const*) @ 0x000000001184cedd 10. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001184858b 11. /build/src/IO/ReadWriteBufferFromHTTP.cpp:465: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x000000001184bf0b 12. /build/src/IO/ReadBuffer.h:60: DB::ReadBuffer::next() @ 0x000000000a148c7b 13. /build/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) @ 0x0000000011849fb2 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]>&)>&, 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&) @ 0x0000000011841980 15. /build/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) @ 0x000000001621208e 16. /build/src/Storages/StorageReplicatedMergeTree.cpp:5228: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl[abi:se190107] const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000015f9a5fe 17. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000015ed8bfd 18. /build/src/Storages/StorageReplicatedMergeTree.cpp:2514: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x0000000015ec9aab 19. /build/src/Storages/StorageReplicatedMergeTree.cpp:2349: DB::StorageReplicatedMergeTree::executeLogEntry(DB::ReplicatedMergeTreeLogEntry&) @ 0x0000000015eba91b 20. /build/src/Storages/StorageReplicatedMergeTree.cpp:3876: bool std::__function::__policy_invoker&)>::__call_impl[abi:se190107])::$_1, bool (std::shared_ptr&)>>(std::__function::__policy_storage const*, std::shared_ptr&) @ 0x0000000015f9837e 21. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000165d6fc3 22. /build/src/Storages/StorageReplicatedMergeTree.cpp:3872: DB::StorageReplicatedMergeTree::processQueueEntry(std::shared_ptr) @ 0x0000000015efc18a 23. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001624c1b2 24. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000162f9c70 25. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x00000000162fa55a 26. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc6653 27. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000000fccc4c3 28. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc3d92 29. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fcca080 30. ? @ 0x00007fbc6213eac3 31. ? @ 0x00007fbc621d0850 (version 25.3.6.10636.altinitytest (altinity build)) 2025.07.28 11:52:45.542366 [ 5825 ] {7fbc825b-1923-4f34-9a45-51127a7c955f} executeQuery: Code: 47. DB::Exception: Unknown expression or function identifier `x` in scope x = 1. (UNKNOWN_IDENTIFIER) (version 25.3.6.10636.altinitytest (altinity build)) (from [::1]:34674) (comment: 01213_alter_rename_with_default_zookeeper_long.sql) (query 4, line 19) (in query: SELECT * FROM table_rename_with_default WHERE key = 1 FORMAT TSVWithNames;), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.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&&) @ 0x000000001404b3b9 4. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3771: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000001401b849 5. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3980: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000014018e31 6. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:2925: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000001402fcbd 7. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3838: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000014019a9e 8. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:209: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000001401270e 9. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000014011fce 10. /build/src/Planner/Utils.cpp:458: DB::buildFilterInfo(std::shared_ptr, std::shared_ptr const&, std::shared_ptr&, std::unordered_set, std::equal_to, std::allocator>) @ 0x0000000013fe8bcf 11. /build/src/Planner/PlannerJoinTree.cpp:535: DB::(anonymous namespace)::buildQueryPlanForTableExpression(std::shared_ptr, std::shared_ptr const&, DB::SelectQueryInfo const&, DB::SelectQueryOptions const&, std::shared_ptr&, bool, bool) @ 0x00000000149956d3 12. /build/src/Planner/PlannerJoinTree.cpp:2252: DB::buildJoinTreeQueryPlan(std::shared_ptr const&, DB::SelectQueryInfo const&, DB::SelectQueryOptions&, std::unordered_set, std::equal_to, std::allocator> const&, std::shared_ptr&) @ 0x000000001498e109 13. /build/src/Planner/Planner.cpp:1553: DB::Planner::buildPlanForQueryNode() @ 0x0000000014979dae 14. /build/src/Planner/Planner.cpp:1308: DB::Planner::buildQueryPlanIfNeeded() @ 0x000000001497685c 15. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:255: DB::InterpreterSelectQueryAnalyzer::getQueryPlan() @ 0x000000001497476d 16. /build/src/Interpreters/executeQuery.cpp:1405: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88806 17. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 18. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 19. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 20. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 21. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 22. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 23. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 24. ? @ 0x00007fbc6213eac3 25. ? @ 0x00007fbc621d0850 2025.07.28 11:52:45.558395 [ 5825 ] {} TCPHandler: Code: 47. DB::Exception: Unknown expression or function identifier `x` in scope x = 1. (UNKNOWN_IDENTIFIER), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.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&&) @ 0x000000001404b3b9 4. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3771: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000001401b849 5. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3980: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000014018e31 6. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:2925: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000001402fcbd 7. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3838: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000014019a9e 8. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:209: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000001401270e 9. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000014011fce 10. /build/src/Planner/Utils.cpp:458: DB::buildFilterInfo(std::shared_ptr, std::shared_ptr const&, std::shared_ptr&, std::unordered_set, std::equal_to, std::allocator>) @ 0x0000000013fe8bcf 11. /build/src/Planner/PlannerJoinTree.cpp:535: DB::(anonymous namespace)::buildQueryPlanForTableExpression(std::shared_ptr, std::shared_ptr const&, DB::SelectQueryInfo const&, DB::SelectQueryOptions const&, std::shared_ptr&, bool, bool) @ 0x00000000149956d3 12. /build/src/Planner/PlannerJoinTree.cpp:2252: DB::buildJoinTreeQueryPlan(std::shared_ptr const&, DB::SelectQueryInfo const&, DB::SelectQueryOptions&, std::unordered_set, std::equal_to, std::allocator> const&, std::shared_ptr&) @ 0x000000001498e109 13. /build/src/Planner/Planner.cpp:1553: DB::Planner::buildPlanForQueryNode() @ 0x0000000014979dae 14. /build/src/Planner/Planner.cpp:1308: DB::Planner::buildQueryPlanIfNeeded() @ 0x000000001497685c 15. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:255: DB::InterpreterSelectQueryAnalyzer::getQueryPlan() @ 0x000000001497476d 16. /build/src/Interpreters/executeQuery.cpp:1405: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88806 17. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 18. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 19. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 20. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 21. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 22. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 23. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 24. ? @ 0x00007fbc6213eac3 25. ? @ 0x00007fbc621d0850 2025.07.28 11:52:46.559435 [ 3960 ] {} test_13.rmt2 (7f9b740d-015c-470e-8cc6-8ba33be0dc63): auto DB::StorageReplicatedMergeTree::processQueueEntry(ReplicatedMergeTreeQueue::SelectedEntryPtr)::(anonymous class)::operator()(LogEntryPtr &) const: Code: 86. DB::HTTPException: Received error from remote server http://146b4357c08d:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Ftest%2F01165%2Ftest_13%2Frmt%2Freplicas%2F1&part=20250728_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.6.10636.altinitytest (altinity build)) '. (RECEIVED_ERROR_FROM_REMOTE_IO_SERVER), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.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 const&, int&&, String const&, unsigned long&&, String const&) @ 0x000000000feda8d9 4. /build/src/IO/HTTPCommon.cpp:104: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x000000000feda6e2 5. /build/src/IO/HTTPCommon.cpp:93: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x000000000feda537 6. /build/src/IO/ReadWriteBufferFromHTTP.cpp:277: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x000000001184a4c4 7. /build/src/IO/ReadWriteBufferFromHTTP.cpp:285: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x000000001184a615 8. /build/src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x000000001184ae59 9. /build/src/IO/ReadWriteBufferFromHTTP.cpp:472: void std::__function::__policy_invoker::__call_impl[abi:se190107]>(std::__function::__policy_storage const*) @ 0x000000001184cedd 10. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001184858b 11. /build/src/IO/ReadWriteBufferFromHTTP.cpp:465: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x000000001184bf0b 12. /build/src/IO/ReadBuffer.h:60: DB::ReadBuffer::next() @ 0x000000000a148c7b 13. /build/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) @ 0x0000000011849fb2 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]>&)>&, 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&) @ 0x0000000011841980 15. /build/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) @ 0x000000001621208e 16. /build/src/Storages/StorageReplicatedMergeTree.cpp:5228: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl[abi:se190107] const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000015f9a5fe 17. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000015ed8bfd 18. /build/src/Storages/StorageReplicatedMergeTree.cpp:2514: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x0000000015ec9aab 19. /build/src/Storages/StorageReplicatedMergeTree.cpp:2349: DB::StorageReplicatedMergeTree::executeLogEntry(DB::ReplicatedMergeTreeLogEntry&) @ 0x0000000015eba91b 20. /build/src/Storages/StorageReplicatedMergeTree.cpp:3876: bool std::__function::__policy_invoker&)>::__call_impl[abi:se190107])::$_1, bool (std::shared_ptr&)>>(std::__function::__policy_storage const*, std::shared_ptr&) @ 0x0000000015f9837e 21. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000165d6fc3 22. /build/src/Storages/StorageReplicatedMergeTree.cpp:3872: DB::StorageReplicatedMergeTree::processQueueEntry(std::shared_ptr) @ 0x0000000015efc18a 23. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001624c1b2 24. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000162f9c70 25. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x00000000162fa55a 26. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc6653 27. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000000fccc4c3 28. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc3d92 29. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fcca080 30. ? @ 0x00007fbc6213eac3 31. ? @ 0x00007fbc621d0850 (version 25.3.6.10636.altinitytest (altinity build)) 2025.07.28 11:52:46.577347 [ 12807 ] {dd33c1c4-9743-493b-9ad2-987442b69725} executeQuery: Code: 47. DB::Exception: Unknown expression or function identifier `x` in scope x = 1. (UNKNOWN_IDENTIFIER) (version 25.3.6.10636.altinitytest (altinity build)) (from [::ffff:127.0.0.1]:58488) (comment: 03114_analyzer_cte_with_join.sql) (query 5, line 11) (in query: SELECT `__table1`.`ID` AS `ID`, `__table2`.`column_a` AS `column_a`, `__table4`.`column_b` AS `column_b` FROM `test_1`.`t` AS `__table1` ALL INNER JOIN (SELECT 1 AS `column_a` FROM `system`.`one` AS `__table3`) AS `__table2` ON `__table1`.`ID` = `__table2`.`column_a` ALL INNER JOIN (SELECT 2 AS `column_b` FROM `system`.`one` AS `__table5`) AS `__table4` ON `__table1`.`ID` = `__table4`.`column_b`), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.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&&) @ 0x000000001404b3b9 4. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3771: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000001401b849 5. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3980: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000014018e31 6. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:2925: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000001402fcbd 7. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3838: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000014019a9e 8. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:209: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000001401270e 9. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000014011fce 10. /build/src/Planner/Utils.cpp:458: DB::buildFilterInfo(std::shared_ptr, std::shared_ptr const&, std::shared_ptr&, std::unordered_set, std::equal_to, std::allocator>) @ 0x0000000013fe8bcf 11. /build/src/Planner/PlannerJoinTree.cpp:535: DB::(anonymous namespace)::buildQueryPlanForTableExpression(std::shared_ptr, std::shared_ptr const&, DB::SelectQueryInfo const&, DB::SelectQueryOptions const&, std::shared_ptr&, bool, bool) @ 0x00000000149956d3 12. /build/src/Planner/PlannerJoinTree.cpp:2252: DB::buildJoinTreeQueryPlan(std::shared_ptr const&, DB::SelectQueryInfo const&, DB::SelectQueryOptions&, std::unordered_set, std::equal_to, std::allocator> const&, std::shared_ptr&) @ 0x000000001498e109 13. /build/src/Planner/Planner.cpp:1553: DB::Planner::buildPlanForQueryNode() @ 0x0000000014979dae 14. /build/src/Planner/Planner.cpp:1308: DB::Planner::buildQueryPlanIfNeeded() @ 0x000000001497685c 15. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:255: DB::InterpreterSelectQueryAnalyzer::getQueryPlan() @ 0x000000001497476d 16. /build/src/Interpreters/executeQuery.cpp:1405: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88806 17. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 18. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 19. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 20. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 21. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 22. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 23. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 24. ? @ 0x00007fbc6213eac3 25. ? @ 0x00007fbc621d0850 2025.07.28 11:52:46.585407 [ 12807 ] {} TCPHandler: Code: 47. DB::Exception: Unknown expression or function identifier `x` in scope x = 1. (UNKNOWN_IDENTIFIER), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.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&&) @ 0x000000001404b3b9 4. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3771: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000001401b849 5. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3980: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000014018e31 6. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:2925: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000001402fcbd 7. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3838: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000014019a9e 8. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:209: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000001401270e 9. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000014011fce 10. /build/src/Planner/Utils.cpp:458: DB::buildFilterInfo(std::shared_ptr, std::shared_ptr const&, std::shared_ptr&, std::unordered_set, std::equal_to, std::allocator>) @ 0x0000000013fe8bcf 11. /build/src/Planner/PlannerJoinTree.cpp:535: DB::(anonymous namespace)::buildQueryPlanForTableExpression(std::shared_ptr, std::shared_ptr const&, DB::SelectQueryInfo const&, DB::SelectQueryOptions const&, std::shared_ptr&, bool, bool) @ 0x00000000149956d3 12. /build/src/Planner/PlannerJoinTree.cpp:2252: DB::buildJoinTreeQueryPlan(std::shared_ptr const&, DB::SelectQueryInfo const&, DB::SelectQueryOptions&, std::unordered_set, std::equal_to, std::allocator> const&, std::shared_ptr&) @ 0x000000001498e109 13. /build/src/Planner/Planner.cpp:1553: DB::Planner::buildPlanForQueryNode() @ 0x0000000014979dae 14. /build/src/Planner/Planner.cpp:1308: DB::Planner::buildQueryPlanIfNeeded() @ 0x000000001497685c 15. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:255: DB::InterpreterSelectQueryAnalyzer::getQueryPlan() @ 0x000000001497476d 16. /build/src/Interpreters/executeQuery.cpp:1405: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88806 17. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 18. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 19. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 20. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 21. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 22. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 23. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 24. ? @ 0x00007fbc6213eac3 25. ? @ 0x00007fbc621d0850 2025.07.28 11:52:46.602249 [ 17208 ] {82be61c4-c68a-4cf6-974a-e51103a2b957} executeQuery: Code: 47. DB::Exception: Unknown expression or function identifier `x` in scope x = 1. (UNKNOWN_IDENTIFIER) (version 25.3.6.10636.altinitytest (altinity build)) (from [::ffff:127.0.0.1]:47288) (comment: 03114_analyzer_cte_with_join.sql) (query 5, line 11) (in query: SELECT `__table1`.`ID` AS `ID`, `__table2`.`column_a` AS `column_a`, `__table4`.`column_b` AS `column_b` FROM `test_1`.`t` AS `__table1` ALL INNER JOIN (SELECT 1 AS `column_a` FROM `system`.`one` AS `__table3`) AS `__table2` ON `__table1`.`ID` = `__table2`.`column_a` ALL INNER JOIN (SELECT 2 AS `column_b` FROM `system`.`one` AS `__table5`) AS `__table4` ON `__table1`.`ID` = `__table4`.`column_b`), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.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&&) @ 0x000000001404b3b9 4. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3771: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000001401b849 5. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3980: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000014018e31 6. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:2925: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000001402fcbd 7. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3838: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000014019a9e 8. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:209: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000001401270e 9. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000014011fce 10. /build/src/Planner/Utils.cpp:458: DB::buildFilterInfo(std::shared_ptr, std::shared_ptr const&, std::shared_ptr&, std::unordered_set, std::equal_to, std::allocator>) @ 0x0000000013fe8bcf 11. /build/src/Planner/PlannerJoinTree.cpp:535: DB::(anonymous namespace)::buildQueryPlanForTableExpression(std::shared_ptr, std::shared_ptr const&, DB::SelectQueryInfo const&, DB::SelectQueryOptions const&, std::shared_ptr&, bool, bool) @ 0x00000000149956d3 12. /build/src/Planner/PlannerJoinTree.cpp:2252: DB::buildJoinTreeQueryPlan(std::shared_ptr const&, DB::SelectQueryInfo const&, DB::SelectQueryOptions&, std::unordered_set, std::equal_to, std::allocator> const&, std::shared_ptr&) @ 0x000000001498e109 13. /build/src/Planner/Planner.cpp:1553: DB::Planner::buildPlanForQueryNode() @ 0x0000000014979dae 14. /build/src/Planner/Planner.cpp:1308: DB::Planner::buildQueryPlanIfNeeded() @ 0x000000001497685c 15. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:255: DB::InterpreterSelectQueryAnalyzer::getQueryPlan() @ 0x000000001497476d 16. /build/src/Interpreters/executeQuery.cpp:1405: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88806 17. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 18. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 19. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 20. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 21. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 22. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 23. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 24. ? @ 0x00007fbc6213eac3 25. ? @ 0x00007fbc621d0850 2025.07.28 11:52:46.609462 [ 17208 ] {} TCPHandler: Code: 47. DB::Exception: Unknown expression or function identifier `x` in scope x = 1. (UNKNOWN_IDENTIFIER), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.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&&) @ 0x000000001404b3b9 4. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3771: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000001401b849 5. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3980: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000014018e31 6. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:2925: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000001402fcbd 7. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3838: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000014019a9e 8. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:209: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000001401270e 9. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000014011fce 10. /build/src/Planner/Utils.cpp:458: DB::buildFilterInfo(std::shared_ptr, std::shared_ptr const&, std::shared_ptr&, std::unordered_set, std::equal_to, std::allocator>) @ 0x0000000013fe8bcf 11. /build/src/Planner/PlannerJoinTree.cpp:535: DB::(anonymous namespace)::buildQueryPlanForTableExpression(std::shared_ptr, std::shared_ptr const&, DB::SelectQueryInfo const&, DB::SelectQueryOptions const&, std::shared_ptr&, bool, bool) @ 0x00000000149956d3 12. /build/src/Planner/PlannerJoinTree.cpp:2252: DB::buildJoinTreeQueryPlan(std::shared_ptr const&, DB::SelectQueryInfo const&, DB::SelectQueryOptions&, std::unordered_set, std::equal_to, std::allocator> const&, std::shared_ptr&) @ 0x000000001498e109 13. /build/src/Planner/Planner.cpp:1553: DB::Planner::buildPlanForQueryNode() @ 0x0000000014979dae 14. /build/src/Planner/Planner.cpp:1308: DB::Planner::buildQueryPlanIfNeeded() @ 0x000000001497685c 15. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:255: DB::InterpreterSelectQueryAnalyzer::getQueryPlan() @ 0x000000001497476d 16. /build/src/Interpreters/executeQuery.cpp:1405: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88806 17. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 18. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 19. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 20. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 21. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 22. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 23. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 24. ? @ 0x00007fbc6213eac3 25. ? @ 0x00007fbc621d0850 2025.07.28 11:52:46.615162 [ 11826 ] {2e5fbe87-322e-40c9-bbc9-16e5093f45dd} executeQuery: Code: 47. DB::Exception: Received from 127.0.0.1:9000. DB::Exception: Unknown expression or function identifier `x` in scope x = 1. Stack trace: 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.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&&) @ 0x000000001404b3b9 4. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3771: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000001401b849 5. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3980: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000014018e31 6. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:2925: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000001402fcbd 7. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3838: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000014019a9e 8. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:209: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000001401270e 9. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000014011fce 10. /build/src/Planner/Utils.cpp:458: DB::buildFilterInfo(std::shared_ptr, std::shared_ptr const&, std::shared_ptr&, std::unordered_set, std::equal_to, std::allocator>) @ 0x0000000013fe8bcf 11. /build/src/Planner/PlannerJoinTree.cpp:535: DB::(anonymous namespace)::buildQueryPlanForTableExpression(std::shared_ptr, std::shared_ptr const&, DB::SelectQueryInfo const&, DB::SelectQueryOptions const&, std::shared_ptr&, bool, bool) @ 0x00000000149956d3 12. /build/src/Planner/PlannerJoinTree.cpp:2252: DB::buildJoinTreeQueryPlan(std::shared_ptr const&, DB::SelectQueryInfo const&, DB::SelectQueryOptions&, std::unordered_set, std::equal_to, std::allocator> const&, std::shared_ptr&) @ 0x000000001498e109 13. /build/src/Planner/Planner.cpp:1553: DB::Planner::buildPlanForQueryNode() @ 0x0000000014979dae 14. /build/src/Planner/Planner.cpp:1308: DB::Planner::buildQueryPlanIfNeeded() @ 0x000000001497685c 15. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:255: DB::InterpreterSelectQueryAnalyzer::getQueryPlan() @ 0x000000001497476d 16. /build/src/Interpreters/executeQuery.cpp:1405: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88806 17. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 18. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 19. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 20. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 21. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 22. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 23. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 24. ? @ 0x00007fbc6213eac3 25. ? @ 0x00007fbc621d0850 : While executing Remote. (UNKNOWN_IDENTIFIER) (version 25.3.6.10636.altinitytest (altinity build)) (from [::1]:34730) (comment: 03114_analyzer_cte_with_join.sql) (query 5, line 11) (in query: with a as (select 1 as column_a) , b as (select 2 as column_b) select * FROM remote('127.0.0.{1,2}', currentDatabase(), t) as c inner join a on ID=column_a inner join b on ID=column_b;), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:111: DB::readException(DB::ReadBuffer&, String const&, bool) @ 0x000000000fc6e157 3. /build/src/Client/Connection.cpp:1445: DB::Connection::receiveException() const @ 0x00000000167d4127 4. /build/src/Client/Connection.cpp:1274: DB::Connection::receivePacket() @ 0x00000000167db312 5. /build/src/Client/PacketReceiver.cpp:66: DB::PacketReceiver::Task::run(std::function, std::function) @ 0x0000000016819393 6. /build/src/Common/AsyncTaskExecutor.cpp:89: DB::AsyncTaskExecutor::Routine::operator()(std::function) @ 0x0000000013bd1892 7. /build/src/Common/Fiber.h:76: boost::context::detail::fiber_record>::run(void*) @ 0x0000000013bd16fa 8. /build/contrib/boost/boost/context/fiber_fcontext.hpp:97: void boost::context::detail::fiber_entry>>(boost::context::detail::transfer_t) @ 0x0000000013bd1621 2025.07.28 11:52:46.676898 [ 11826 ] {} TCPHandler: Code: 47. DB::Exception: Received from 127.0.0.1:9000. DB::Exception: Unknown expression or function identifier `x` in scope x = 1. Stack trace: 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.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&&) @ 0x000000001404b3b9 4. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3771: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000001401b849 5. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3980: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000014018e31 6. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:2925: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000001402fcbd 7. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3838: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000014019a9e 8. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:209: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000001401270e 9. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000014011fce 10. /build/src/Planner/Utils.cpp:458: DB::buildFilterInfo(std::shared_ptr, std::shared_ptr const&, std::shared_ptr&, std::unordered_set, std::equal_to, std::allocator>) @ 0x0000000013fe8bcf 11. /build/src/Planner/PlannerJoinTree.cpp:535: DB::(anonymous namespace)::buildQueryPlanForTableExpression(std::shared_ptr, std::shared_ptr const&, DB::SelectQueryInfo const&, DB::SelectQueryOptions const&, std::shared_ptr&, bool, bool) @ 0x00000000149956d3 12. /build/src/Planner/PlannerJoinTree.cpp:2252: DB::buildJoinTreeQueryPlan(std::shared_ptr const&, DB::SelectQueryInfo const&, DB::SelectQueryOptions&, std::unordered_set, std::equal_to, std::allocator> const&, std::shared_ptr&) @ 0x000000001498e109 13. /build/src/Planner/Planner.cpp:1553: DB::Planner::buildPlanForQueryNode() @ 0x0000000014979dae 14. /build/src/Planner/Planner.cpp:1308: DB::Planner::buildQueryPlanIfNeeded() @ 0x000000001497685c 15. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:255: DB::InterpreterSelectQueryAnalyzer::getQueryPlan() @ 0x000000001497476d 16. /build/src/Interpreters/executeQuery.cpp:1405: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88806 17. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 18. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 19. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 20. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 21. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 22. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 23. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 24. ? @ 0x00007fbc6213eac3 25. ? @ 0x00007fbc621d0850 : While executing Remote. (UNKNOWN_IDENTIFIER), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:111: DB::readException(DB::ReadBuffer&, String const&, bool) @ 0x000000000fc6e157 3. /build/src/Client/Connection.cpp:1445: DB::Connection::receiveException() const @ 0x00000000167d4127 4. /build/src/Client/Connection.cpp:1274: DB::Connection::receivePacket() @ 0x00000000167db312 5. /build/src/Client/PacketReceiver.cpp:66: DB::PacketReceiver::Task::run(std::function, std::function) @ 0x0000000016819393 6. /build/src/Common/AsyncTaskExecutor.cpp:89: DB::AsyncTaskExecutor::Routine::operator()(std::function) @ 0x0000000013bd1892 7. /build/src/Common/Fiber.h:76: boost::context::detail::fiber_record>::run(void*) @ 0x0000000013bd16fa 8. /build/contrib/boost/boost/context/fiber_fcontext.hpp:97: void boost::context::detail::fiber_entry>>(boost::context::detail::transfer_t) @ 0x0000000013bd1621 Job's origin stack trace: 0. /build/src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000000fc33b84 1. /build/src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000000fcc2ea7 2. /build/src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fcc535c 3. /build/src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000000fcc584d 4. /build/src/Common/ThreadPool.h:279: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x00000000169bf193 5. /build/src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x00000000169bf518 6. /build/src/Server/TCPHandler.cpp:1237: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x00000000168f1525 7. /build/src/Server/TCPHandler.cpp:678: DB::TCPHandler::runImpl() @ 0x00000000168e68e5 8. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 9. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 10. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 11. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 12. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 13. ? @ 0x00007fbc6213eac3 14. ? @ 0x00007fbc621d0850 2025.07.28 11:52:46.724327 [ 17252 ] {6b7ab96d-4c88-47cc-96cd-5c4c1796913c} executeQuery: Code: 452. DB::Exception: Setting allow_experimental_object_type should not be changed. (SETTING_CONSTRAINT_VIOLATION) (version 25.3.6.10636.altinitytest (altinity build)) (from [::1]:34762) (comment: 02910_object-json-crash-add-column.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. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x000000000c25bc4b 4. /build/src/Access/SettingsConstraints.cpp:343: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000138596e3 5. /build/src/Access/SettingsConstraints.cpp:300: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000013858faf 6. /build/src/Access/SettingsConstraints.cpp:194: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges const&, DB::SettingSource) const @ 0x00000000138591b3 7. /build/src/Interpreters/Context.cpp:2722: DB::Context::checkSettingsConstraints(DB::SettingsChanges const&, DB::SettingSource) @ 0x0000000014436509 8. /build/src/Interpreters/InterpreterSetQuery.cpp:28: DB::InterpreterSetQuery::execute() @ 0x00000000149e240a 9. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88dc9 10. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 11. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 12. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 13. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 14. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 16. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 17. ? @ 0x00007fbc6213eac3 18. ? @ 0x00007fbc621d0850 2025.07.28 11:52:46.737097 [ 17252 ] {} 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. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x000000000c25bc4b 4. /build/src/Access/SettingsConstraints.cpp:343: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000138596e3 5. /build/src/Access/SettingsConstraints.cpp:300: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000013858faf 6. /build/src/Access/SettingsConstraints.cpp:194: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges const&, DB::SettingSource) const @ 0x00000000138591b3 7. /build/src/Interpreters/Context.cpp:2722: DB::Context::checkSettingsConstraints(DB::SettingsChanges const&, DB::SettingSource) @ 0x0000000014436509 8. /build/src/Interpreters/InterpreterSetQuery.cpp:28: DB::InterpreterSetQuery::execute() @ 0x00000000149e240a 9. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88dc9 10. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 11. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 12. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 13. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 14. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 16. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 17. ? @ 0x00007fbc6213eac3 18. ? @ 0x00007fbc621d0850 2025.07.28 11:52:46.938334 [ 17371 ] {b0aae95a-7655-4e63-8346-497ff9ae66e6} 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('hello', 'a', 'b'). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.6.10636.altinitytest (altinity build)) (from [::1]:34602) (comment: 03315_trim_two_args.sql) (query 22, line 97) (in query: SELECT trimLeft('hello', 'a', 'b');), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&, String&&) @ 0x0000000012da6feb 4. /build/src/Functions/FunctionHelpers.cpp:184: DB::validateFunctionArguments(DB::IFunction const&, std::vector> const&, std::vector> const&, std::vector> const&) @ 0x0000000012da5831 5. /build/src/Functions/trim.cpp:41: DB::(anonymous namespace)::FunctionTrim::getReturnTypeImpl(std::vector> const&) const @ 0x000000000e92982e 6. /build/src/Functions/IFunction.cpp:645: DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x0000000012d96b0c 7. /build/src/Functions/IFunction.cpp:577: DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x0000000012d9669c 8. /build/src/Functions/IFunction.cpp:606: DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x0000000012d96edc 9. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3544: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000014033cc9 10. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3838: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000014019a9e 11. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3980: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000014018e31 12. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:4304: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000014042fa7 13. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5605: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000014013749 14. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000140127f9 15. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000014011fce 16. /build/src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000001406ce8a 17. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000014973b42 18. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000001497268d 19. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000014974d24 20. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001492924b 21. /build/src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88641 22. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 23. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 24. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 25. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 26. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 27. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 28. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 29. ? @ 0x00007fbc6213eac3 30. ? @ 0x00007fbc621d0850 2025.07.28 11:52:46.945193 [ 17371 ] {} 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('hello', 'a', 'b'). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&, String&&) @ 0x0000000012da6feb 4. /build/src/Functions/FunctionHelpers.cpp:184: DB::validateFunctionArguments(DB::IFunction const&, std::vector> const&, std::vector> const&, std::vector> const&) @ 0x0000000012da5831 5. /build/src/Functions/trim.cpp:41: DB::(anonymous namespace)::FunctionTrim::getReturnTypeImpl(std::vector> const&) const @ 0x000000000e92982e 6. /build/src/Functions/IFunction.cpp:645: DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x0000000012d96b0c 7. /build/src/Functions/IFunction.cpp:577: DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x0000000012d9669c 8. /build/src/Functions/IFunction.cpp:606: DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x0000000012d96edc 9. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3544: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000014033cc9 10. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3838: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000014019a9e 11. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3980: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000014018e31 12. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:4304: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000014042fa7 13. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5605: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000014013749 14. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000140127f9 15. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000014011fce 16. /build/src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000001406ce8a 17. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000014973b42 18. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000001497268d 19. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000014974d24 20. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001492924b 21. /build/src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88641 22. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 23. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 24. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 25. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 26. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 27. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 28. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 29. ? @ 0x00007fbc6213eac3 30. ? @ 0x00007fbc621d0850 2025.07.28 11:52:47.091448 [ 17371 ] {4a9b2ca9-939c-46d2-983e-bed58172b649} executeQuery: Code: 43. DB::Exception: A value of illegal type was provided as 1st argument 'input_string' to function 'trimRight'. Expected: String or FixedString, got: UInt8: In scope SELECT trimRight(123, 'a'). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.6.10636.altinitytest (altinity build)) (from [::1]:34602) (comment: 03315_trim_two_args.sql) (query 23, line 98) (in query: SELECT trimRight(123, 'a');), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: 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&&) @ 0x0000000012da74d9 4. /build/src/Functions/FunctionHelpers.cpp:130: DB::(anonymous namespace)::validateArgumentsImpl(DB::IFunction const&, std::vector> const&, unsigned long, std::vector> const&) @ 0x0000000012da5b15 5. /build/src/Functions/FunctionHelpers.cpp:192: DB::validateFunctionArguments(DB::IFunction const&, std::vector> const&, std::vector> const&, std::vector> const&) @ 0x0000000012da54fb 6. /build/src/Functions/trim.cpp:41: DB::(anonymous namespace)::FunctionTrim::getReturnTypeImpl(std::vector> const&) const @ 0x000000000e92a68e 7. /build/src/Functions/IFunction.cpp:645: DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x0000000012d96b0c 8. /build/src/Functions/IFunction.cpp:577: DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x0000000012d9669c 9. /build/src/Functions/IFunction.cpp:606: DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x0000000012d96edc 10. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3544: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000014033cc9 11. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3838: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000014019a9e 12. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3980: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000014018e31 13. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:4304: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000014042fa7 14. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5605: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000014013749 15. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000140127f9 16. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000014011fce 17. /build/src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000001406ce8a 18. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000014973b42 19. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000001497268d 20. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000014974d24 21. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001492924b 22. /build/src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88641 23. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 24. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 25. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 26. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 27. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 28. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 29. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 30. ? @ 0x00007fbc6213eac3 31. ? @ 0x00007fbc621d0850 2025.07.28 11:52:47.188483 [ 17371 ] {} TCPHandler: Code: 43. DB::Exception: A value of illegal type was provided as 1st argument 'input_string' to function 'trimRight'. Expected: String or FixedString, got: UInt8: In scope SELECT trimRight(123, 'a'). (ILLEGAL_TYPE_OF_ARGUMENT), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: 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&&) @ 0x0000000012da74d9 4. /build/src/Functions/FunctionHelpers.cpp:130: DB::(anonymous namespace)::validateArgumentsImpl(DB::IFunction const&, std::vector> const&, unsigned long, std::vector> const&) @ 0x0000000012da5b15 5. /build/src/Functions/FunctionHelpers.cpp:192: DB::validateFunctionArguments(DB::IFunction const&, std::vector> const&, std::vector> const&, std::vector> const&) @ 0x0000000012da54fb 6. /build/src/Functions/trim.cpp:41: DB::(anonymous namespace)::FunctionTrim::getReturnTypeImpl(std::vector> const&) const @ 0x000000000e92a68e 7. /build/src/Functions/IFunction.cpp:645: DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x0000000012d96b0c 8. /build/src/Functions/IFunction.cpp:577: DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x0000000012d9669c 9. /build/src/Functions/IFunction.cpp:606: DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x0000000012d96edc 10. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3544: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000014033cc9 11. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3838: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000014019a9e 12. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3980: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000014018e31 13. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:4304: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000014042fa7 14. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5605: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000014013749 15. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000140127f9 16. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000014011fce 17. /build/src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000001406ce8a 18. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000014973b42 19. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000001497268d 20. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000014974d24 21. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001492924b 22. /build/src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88641 23. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 24. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 25. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 26. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 27. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 28. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 29. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 30. ? @ 0x00007fbc6213eac3 31. ? @ 0x00007fbc621d0850 2025.07.28 11:52:47.215454 [ 3963 ] {} test_13.rmt2 (7f9b740d-015c-470e-8cc6-8ba33be0dc63): auto DB::StorageReplicatedMergeTree::processQueueEntry(ReplicatedMergeTreeQueue::SelectedEntryPtr)::(anonymous class)::operator()(LogEntryPtr &) const: Code: 86. DB::HTTPException: Received error from remote server http://146b4357c08d:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Ftest%2F01165%2Ftest_13%2Frmt%2Freplicas%2F1&part=20250728_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.6.10636.altinitytest (altinity build)) '. (RECEIVED_ERROR_FROM_REMOTE_IO_SERVER), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.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 const&, int&&, String const&, unsigned long&&, String const&) @ 0x000000000feda8d9 4. /build/src/IO/HTTPCommon.cpp:104: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x000000000feda6e2 5. /build/src/IO/HTTPCommon.cpp:93: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x000000000feda537 6. /build/src/IO/ReadWriteBufferFromHTTP.cpp:277: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x000000001184a4c4 7. /build/src/IO/ReadWriteBufferFromHTTP.cpp:285: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x000000001184a615 8. /build/src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x000000001184ae59 9. /build/src/IO/ReadWriteBufferFromHTTP.cpp:472: void std::__function::__policy_invoker::__call_impl[abi:se190107]>(std::__function::__policy_storage const*) @ 0x000000001184cedd 10. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001184858b 11. /build/src/IO/ReadWriteBufferFromHTTP.cpp:465: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x000000001184bf0b 12. /build/src/IO/ReadBuffer.h:60: DB::ReadBuffer::next() @ 0x000000000a148c7b 13. /build/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) @ 0x0000000011849fb2 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]>&)>&, 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&) @ 0x0000000011841980 15. /build/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) @ 0x000000001621208e 16. /build/src/Storages/StorageReplicatedMergeTree.cpp:5228: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl[abi:se190107] const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000015f9a5fe 17. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000015ed8bfd 18. /build/src/Storages/StorageReplicatedMergeTree.cpp:2514: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x0000000015ec9aab 19. /build/src/Storages/StorageReplicatedMergeTree.cpp:2349: DB::StorageReplicatedMergeTree::executeLogEntry(DB::ReplicatedMergeTreeLogEntry&) @ 0x0000000015eba91b 20. /build/src/Storages/StorageReplicatedMergeTree.cpp:3876: bool std::__function::__policy_invoker&)>::__call_impl[abi:se190107])::$_1, bool (std::shared_ptr&)>>(std::__function::__policy_storage const*, std::shared_ptr&) @ 0x0000000015f9837e 21. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000165d6fc3 22. /build/src/Storages/StorageReplicatedMergeTree.cpp:3872: DB::StorageReplicatedMergeTree::processQueueEntry(std::shared_ptr) @ 0x0000000015efc18a 23. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001624c1b2 24. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000162f9c70 25. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x00000000162fa55a 26. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc6653 27. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000000fccc4c3 28. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc3d92 29. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fcca080 30. ? @ 0x00007fbc6213eac3 31. ? @ 0x00007fbc621d0850 (version 25.3.6.10636.altinitytest (altinity build)) 2025.07.28 11:52:47.395077 [ 17371 ] {2d8a4c5a-380e-423b-96ba-a104e2a6d361} executeQuery: Code: 43. DB::Exception: A value of illegal type was provided as 2nd argument 'trim_character' to function 'trimBoth'. Expected: const String, got: UInt8: In scope SELECT trimBoth('hello', 123). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.6.10636.altinitytest (altinity build)) (from [::1]:34602) (comment: 03315_trim_two_args.sql) (query 24, line 99) (in query: SELECT trimBoth('hello', 123);), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: 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&&) @ 0x0000000012da74d9 4. /build/src/Functions/FunctionHelpers.cpp:130: DB::(anonymous namespace)::validateArgumentsImpl(DB::IFunction const&, std::vector> const&, unsigned long, std::vector> const&) @ 0x0000000012da5b15 5. /build/src/Functions/trim.cpp:41: DB::(anonymous namespace)::FunctionTrim::getReturnTypeImpl(std::vector> const&) const @ 0x000000000e92b78e 6. /build/src/Functions/IFunction.cpp:645: DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x0000000012d96b0c 7. /build/src/Functions/IFunction.cpp:577: DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x0000000012d9669c 8. /build/src/Functions/IFunction.cpp:606: DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x0000000012d96edc 9. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3544: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000014033cc9 10. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3838: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000014019a9e 11. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3980: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000014018e31 12. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:4304: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000014042fa7 13. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5605: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000014013749 14. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000140127f9 15. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000014011fce 16. /build/src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000001406ce8a 17. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000014973b42 18. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000001497268d 19. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000014974d24 20. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001492924b 21. /build/src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88641 22. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 23. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 24. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 25. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 26. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 27. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 28. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 29. ? @ 0x00007fbc6213eac3 30. ? @ 0x00007fbc621d0850 2025.07.28 11:52:47.404471 [ 17371 ] {} TCPHandler: Code: 43. DB::Exception: A value of illegal type was provided as 2nd argument 'trim_character' to function 'trimBoth'. Expected: const String, got: UInt8: In scope SELECT trimBoth('hello', 123). (ILLEGAL_TYPE_OF_ARGUMENT), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: 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&&) @ 0x0000000012da74d9 4. /build/src/Functions/FunctionHelpers.cpp:130: DB::(anonymous namespace)::validateArgumentsImpl(DB::IFunction const&, std::vector> const&, unsigned long, std::vector> const&) @ 0x0000000012da5b15 5. /build/src/Functions/trim.cpp:41: DB::(anonymous namespace)::FunctionTrim::getReturnTypeImpl(std::vector> const&) const @ 0x000000000e92b78e 6. /build/src/Functions/IFunction.cpp:645: DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x0000000012d96b0c 7. /build/src/Functions/IFunction.cpp:577: DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x0000000012d9669c 8. /build/src/Functions/IFunction.cpp:606: DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x0000000012d96edc 9. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3544: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000014033cc9 10. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3838: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000014019a9e 11. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3980: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000014018e31 12. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:4304: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000014042fa7 13. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5605: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000014013749 14. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000140127f9 15. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000014011fce 16. /build/src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000001406ce8a 17. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000014973b42 18. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000001497268d 19. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000014974d24 20. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001492924b 21. /build/src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88641 22. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 23. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 24. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 25. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 26. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 27. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 28. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 29. ? @ 0x00007fbc6213eac3 30. ? @ 0x00007fbc621d0850 2025.07.28 11:52:47.508168 [ 17371 ] {c9e85b60-d9cd-40b2-8707-48a236aad75c} executeQuery: Code: 44. DB::Exception: A value of illegal type was provided as 2nd argument 'trim_character' to function 'trimBoth'. Expected: const String, got: String: In scope SELECT trimBoth('hello', materialize('a')). (ILLEGAL_COLUMN) (version 25.3.6.10636.altinitytest (altinity build)) (from [::1]:34602) (comment: 03315_trim_two_args.sql) (query 25, line 100) (in query: SELECT trimBoth('hello', materialize('a'));), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: 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&&) @ 0x0000000012da74d9 4. /build/src/Functions/FunctionHelpers.cpp:130: DB::(anonymous namespace)::validateArgumentsImpl(DB::IFunction const&, std::vector> const&, unsigned long, std::vector> const&) @ 0x0000000012da5b15 5. /build/src/Functions/trim.cpp:41: DB::(anonymous namespace)::FunctionTrim::getReturnTypeImpl(std::vector> const&) const @ 0x000000000e92b78e 6. /build/src/Functions/IFunction.cpp:645: DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x0000000012d96b0c 7. /build/src/Functions/IFunction.cpp:577: DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x0000000012d9669c 8. /build/src/Functions/IFunction.cpp:606: DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x0000000012d96edc 9. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3544: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000014033cc9 10. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3838: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000014019a9e 11. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3980: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000014018e31 12. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:4304: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000014042fa7 13. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5605: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000014013749 14. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000140127f9 15. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000014011fce 16. /build/src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000001406ce8a 17. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000014973b42 18. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000001497268d 19. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000014974d24 20. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001492924b 21. /build/src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88641 22. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 23. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 24. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 25. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 26. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 27. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 28. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 29. ? @ 0x00007fbc6213eac3 30. ? @ 0x00007fbc621d0850 2025.07.28 11:52:47.513573 [ 17371 ] {} TCPHandler: Code: 44. DB::Exception: A value of illegal type was provided as 2nd argument 'trim_character' to function 'trimBoth'. Expected: const String, got: String: In scope SELECT trimBoth('hello', materialize('a')). (ILLEGAL_COLUMN), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: 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&&) @ 0x0000000012da74d9 4. /build/src/Functions/FunctionHelpers.cpp:130: DB::(anonymous namespace)::validateArgumentsImpl(DB::IFunction const&, std::vector> const&, unsigned long, std::vector> const&) @ 0x0000000012da5b15 5. /build/src/Functions/trim.cpp:41: DB::(anonymous namespace)::FunctionTrim::getReturnTypeImpl(std::vector> const&) const @ 0x000000000e92b78e 6. /build/src/Functions/IFunction.cpp:645: DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x0000000012d96b0c 7. /build/src/Functions/IFunction.cpp:577: DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x0000000012d9669c 8. /build/src/Functions/IFunction.cpp:606: DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x0000000012d96edc 9. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3544: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000014033cc9 10. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3838: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000014019a9e 11. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3980: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000014018e31 12. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:4304: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000014042fa7 13. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5605: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000014013749 14. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000140127f9 15. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000014011fce 16. /build/src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000001406ce8a 17. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000014973b42 18. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000001497268d 19. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000014974d24 20. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001492924b 21. /build/src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88641 22. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 23. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 24. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 25. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 26. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 27. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 28. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 29. ? @ 0x00007fbc6213eac3 30. ? @ 0x00007fbc621d0850 2025.07.28 11:52:47.680225 [ 3967 ] {} test_13.rmt2 (7f9b740d-015c-470e-8cc6-8ba33be0dc63): auto DB::StorageReplicatedMergeTree::processQueueEntry(ReplicatedMergeTreeQueue::SelectedEntryPtr)::(anonymous class)::operator()(LogEntryPtr &) const: Code: 86. DB::HTTPException: Received error from remote server http://146b4357c08d:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Ftest%2F01165%2Ftest_13%2Frmt%2Freplicas%2F1&part=20250728_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.6.10636.altinitytest (altinity build)) '. (RECEIVED_ERROR_FROM_REMOTE_IO_SERVER), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.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 const&, int&&, String const&, unsigned long&&, String const&) @ 0x000000000feda8d9 4. /build/src/IO/HTTPCommon.cpp:104: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x000000000feda6e2 5. /build/src/IO/HTTPCommon.cpp:93: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x000000000feda537 6. /build/src/IO/ReadWriteBufferFromHTTP.cpp:277: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x000000001184a4c4 7. /build/src/IO/ReadWriteBufferFromHTTP.cpp:285: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x000000001184a615 8. /build/src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x000000001184ae59 9. /build/src/IO/ReadWriteBufferFromHTTP.cpp:472: void std::__function::__policy_invoker::__call_impl[abi:se190107]>(std::__function::__policy_storage const*) @ 0x000000001184cedd 10. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001184858b 11. /build/src/IO/ReadWriteBufferFromHTTP.cpp:465: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x000000001184bf0b 12. /build/src/IO/ReadBuffer.h:60: DB::ReadBuffer::next() @ 0x000000000a148c7b 13. /build/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) @ 0x0000000011849fb2 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]>&)>&, 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&) @ 0x0000000011841980 15. /build/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) @ 0x000000001621208e 16. /build/src/Storages/StorageReplicatedMergeTree.cpp:5228: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl[abi:se190107] const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000015f9a5fe 17. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000015ed8bfd 18. /build/src/Storages/StorageReplicatedMergeTree.cpp:2514: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x0000000015ec9aab 19. /build/src/Storages/StorageReplicatedMergeTree.cpp:2349: DB::StorageReplicatedMergeTree::executeLogEntry(DB::ReplicatedMergeTreeLogEntry&) @ 0x0000000015eba91b 20. /build/src/Storages/StorageReplicatedMergeTree.cpp:3876: bool std::__function::__policy_invoker&)>::__call_impl[abi:se190107])::$_1, bool (std::shared_ptr&)>>(std::__function::__policy_storage const*, std::shared_ptr&) @ 0x0000000015f9837e 21. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000165d6fc3 22. /build/src/Storages/StorageReplicatedMergeTree.cpp:3872: DB::StorageReplicatedMergeTree::processQueueEntry(std::shared_ptr) @ 0x0000000015efc18a 23. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001624c1b2 24. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000162f9c70 25. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x00000000162fa55a 26. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc6653 27. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000000fccc4c3 28. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc3d92 29. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fcca080 30. ? @ 0x00007fbc6213eac3 31. ? @ 0x00007fbc621d0850 (version 25.3.6.10636.altinitytest (altinity build)) 2025.07.28 11:52:47.988913 [ 3962 ] {} test_13.rmt2 (7f9b740d-015c-470e-8cc6-8ba33be0dc63): auto DB::StorageReplicatedMergeTree::processQueueEntry(ReplicatedMergeTreeQueue::SelectedEntryPtr)::(anonymous class)::operator()(LogEntryPtr &) const: Code: 86. DB::HTTPException: Received error from remote server http://146b4357c08d:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Ftest%2F01165%2Ftest_13%2Frmt%2Freplicas%2F1&part=20250728_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.6.10636.altinitytest (altinity build)) '. (RECEIVED_ERROR_FROM_REMOTE_IO_SERVER), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.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 const&, int&&, String const&, unsigned long&&, String const&) @ 0x000000000feda8d9 4. /build/src/IO/HTTPCommon.cpp:104: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x000000000feda6e2 5. /build/src/IO/HTTPCommon.cpp:93: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x000000000feda537 6. /build/src/IO/ReadWriteBufferFromHTTP.cpp:277: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x000000001184a4c4 7. /build/src/IO/ReadWriteBufferFromHTTP.cpp:285: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x000000001184a615 8. /build/src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x000000001184ae59 9. /build/src/IO/ReadWriteBufferFromHTTP.cpp:472: void std::__function::__policy_invoker::__call_impl[abi:se190107]>(std::__function::__policy_storage const*) @ 0x000000001184cedd 10. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001184858b 11. /build/src/IO/ReadWriteBufferFromHTTP.cpp:465: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x000000001184bf0b 12. /build/src/IO/ReadBuffer.h:60: DB::ReadBuffer::next() @ 0x000000000a148c7b 13. /build/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) @ 0x0000000011849fb2 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]>&)>&, 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&) @ 0x0000000011841980 15. /build/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) @ 0x000000001621208e 16. /build/src/Storages/StorageReplicatedMergeTree.cpp:5228: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl[abi:se190107] const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000015f9a5fe 17. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000015ed8bfd 18. /build/src/Storages/StorageReplicatedMergeTree.cpp:2514: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x0000000015ec9aab 19. /build/src/Storages/StorageReplicatedMergeTree.cpp:2349: DB::StorageReplicatedMergeTree::executeLogEntry(DB::ReplicatedMergeTreeLogEntry&) @ 0x0000000015eba91b 20. /build/src/Storages/StorageReplicatedMergeTree.cpp:3876: bool std::__function::__policy_invoker&)>::__call_impl[abi:se190107])::$_1, bool (std::shared_ptr&)>>(std::__function::__policy_storage const*, std::shared_ptr&) @ 0x0000000015f9837e 21. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000165d6fc3 22. /build/src/Storages/StorageReplicatedMergeTree.cpp:3872: DB::StorageReplicatedMergeTree::processQueueEntry(std::shared_ptr) @ 0x0000000015efc18a 23. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001624c1b2 24. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000162f9c70 25. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x00000000162fa55a 26. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc6653 27. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000000fccc4c3 28. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc3d92 29. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fcca080 30. ? @ 0x00007fbc6213eac3 31. ? @ 0x00007fbc621d0850 (version 25.3.6.10636.altinitytest (altinity build)) 2025.07.28 11:52:48.535719 [ 17252 ] {ebbb4f25-7840-4712-a031-0fbaae71d105} executeQuery: Code: 167. DB::Exception: AST is too deep. Maximum: 1000. (TOO_DEEP_AST) (version 25.3.6.10636.altinitytest (altinity build)) (from [::ffff:127.0.0.1]:48594) (comment: 01196_max_parser_depth.sh) (in query: select coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, coalesce(null, 1))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))))), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type>, unsigned long&) @ 0x000000000b23df2b 4. /build/src/Parsers/IAST.cpp:162: DB::IAST::checkDepthImpl(unsigned long) const @ 0x0000000017a3576f 5. /build/src/Parsers/IAST.h:99: DB::tryParseQuery(DB::IParser&, char const*&, char const*, String&, bool, String const&, bool, unsigned long, unsigned long, unsigned long, bool) @ 0x0000000017a95b0c 6. /build/src/Parsers/parseQuery.cpp:404: DB::parseQueryAndMovePosition(DB::IParser&, char const*&, char const*, String const&, bool, unsigned long, unsigned long, unsigned long) @ 0x0000000017a96ac6 7. /build/src/Parsers/parseQuery.cpp:424: DB::parseQuery(DB::IParser&, char const*, char const*, String const&, unsigned long, unsigned long, unsigned long) @ 0x0000000017a96bbe 8. /build/src/Interpreters/executeQuery.cpp:955: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c8533e 9. /build/src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x0000000014c8ca7b 10. /build/src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000001686da12 11. /build/src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x0000000016870807 12. /build/src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x0000000016907e99 13. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 14. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 16. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 17. ? @ 0x00007fbc6213eac3 18. ? @ 0x00007fbc621d0850 2025.07.28 11:52:48.600545 [ 17252 ] {ebbb4f25-7840-4712-a031-0fbaae71d105} DynamicQueryHandler: Code: 167. DB::Exception: AST is too deep. Maximum: 1000. (TOO_DEEP_AST), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type>, unsigned long&) @ 0x000000000b23df2b 4. /build/src/Parsers/IAST.cpp:162: DB::IAST::checkDepthImpl(unsigned long) const @ 0x0000000017a3576f 5. /build/src/Parsers/IAST.h:99: DB::tryParseQuery(DB::IParser&, char const*&, char const*, String&, bool, String const&, bool, unsigned long, unsigned long, unsigned long, bool) @ 0x0000000017a95b0c 6. /build/src/Parsers/parseQuery.cpp:404: DB::parseQueryAndMovePosition(DB::IParser&, char const*&, char const*, String const&, bool, unsigned long, unsigned long, unsigned long) @ 0x0000000017a96ac6 7. /build/src/Parsers/parseQuery.cpp:424: DB::parseQuery(DB::IParser&, char const*, char const*, String const&, unsigned long, unsigned long, unsigned long) @ 0x0000000017a96bbe 8. /build/src/Interpreters/executeQuery.cpp:955: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c8533e 9. /build/src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x0000000014c8ca7b 10. /build/src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000001686da12 11. /build/src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x0000000016870807 12. /build/src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x0000000016907e99 13. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 14. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 16. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 17. ? @ 0x00007fbc6213eac3 18. ? @ 0x00007fbc621d0850 (version 25.3.6.10636.altinitytest (altinity build)) 2025.07.28 11:52:48.876154 [ 3965 ] {} test_13.rmt2 (7f9b740d-015c-470e-8cc6-8ba33be0dc63): auto DB::StorageReplicatedMergeTree::processQueueEntry(ReplicatedMergeTreeQueue::SelectedEntryPtr)::(anonymous class)::operator()(LogEntryPtr &) const: Code: 86. DB::HTTPException: Received error from remote server http://146b4357c08d:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Ftest%2F01165%2Ftest_13%2Frmt%2Freplicas%2F1&part=20250728_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.6.10636.altinitytest (altinity build)) '. (RECEIVED_ERROR_FROM_REMOTE_IO_SERVER), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.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 const&, int&&, String const&, unsigned long&&, String const&) @ 0x000000000feda8d9 4. /build/src/IO/HTTPCommon.cpp:104: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x000000000feda6e2 5. /build/src/IO/HTTPCommon.cpp:93: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x000000000feda537 6. /build/src/IO/ReadWriteBufferFromHTTP.cpp:277: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x000000001184a4c4 7. /build/src/IO/ReadWriteBufferFromHTTP.cpp:285: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x000000001184a615 8. /build/src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x000000001184ae59 9. /build/src/IO/ReadWriteBufferFromHTTP.cpp:472: void std::__function::__policy_invoker::__call_impl[abi:se190107]>(std::__function::__policy_storage const*) @ 0x000000001184cedd 10. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001184858b 11. /build/src/IO/ReadWriteBufferFromHTTP.cpp:465: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x000000001184bf0b 12. /build/src/IO/ReadBuffer.h:60: DB::ReadBuffer::next() @ 0x000000000a148c7b 13. /build/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) @ 0x0000000011849fb2 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]>&)>&, 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&) @ 0x0000000011841980 15. /build/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) @ 0x000000001621208e 16. /build/src/Storages/StorageReplicatedMergeTree.cpp:5228: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl[abi:se190107] const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000015f9a5fe 17. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000015ed8bfd 18. /build/src/Storages/StorageReplicatedMergeTree.cpp:2514: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x0000000015ec9aab 19. /build/src/Storages/StorageReplicatedMergeTree.cpp:2349: DB::StorageReplicatedMergeTree::executeLogEntry(DB::ReplicatedMergeTreeLogEntry&) @ 0x0000000015eba91b 20. /build/src/Storages/StorageReplicatedMergeTree.cpp:3876: bool std::__function::__policy_invoker&)>::__call_impl[abi:se190107])::$_1, bool (std::shared_ptr&)>>(std::__function::__policy_storage const*, std::shared_ptr&) @ 0x0000000015f9837e 21. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000165d6fc3 22. /build/src/Storages/StorageReplicatedMergeTree.cpp:3872: DB::StorageReplicatedMergeTree::processQueueEntry(std::shared_ptr) @ 0x0000000015efc18a 23. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001624c1b2 24. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000162f9c70 25. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x00000000162fa55a 26. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc6653 27. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000000fccc4c3 28. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc3d92 29. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fcca080 30. ? @ 0x00007fbc6213eac3 31. ? @ 0x00007fbc621d0850 (version 25.3.6.10636.altinitytest (altinity build)) 2025.07.28 11:52:49.711128 [ 3960 ] {} test_13.rmt2 (7f9b740d-015c-470e-8cc6-8ba33be0dc63): auto DB::StorageReplicatedMergeTree::processQueueEntry(ReplicatedMergeTreeQueue::SelectedEntryPtr)::(anonymous class)::operator()(LogEntryPtr &) const: Code: 86. DB::HTTPException: Received error from remote server http://146b4357c08d:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Ftest%2F01165%2Ftest_13%2Frmt%2Freplicas%2F1&part=20250728_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.6.10636.altinitytest (altinity build)) '. (RECEIVED_ERROR_FROM_REMOTE_IO_SERVER), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.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 const&, int&&, String const&, unsigned long&&, String const&) @ 0x000000000feda8d9 4. /build/src/IO/HTTPCommon.cpp:104: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x000000000feda6e2 5. /build/src/IO/HTTPCommon.cpp:93: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x000000000feda537 6. /build/src/IO/ReadWriteBufferFromHTTP.cpp:277: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x000000001184a4c4 7. /build/src/IO/ReadWriteBufferFromHTTP.cpp:285: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x000000001184a615 8. /build/src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x000000001184ae59 9. /build/src/IO/ReadWriteBufferFromHTTP.cpp:472: void std::__function::__policy_invoker::__call_impl[abi:se190107]>(std::__function::__policy_storage const*) @ 0x000000001184cedd 10. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001184858b 11. /build/src/IO/ReadWriteBufferFromHTTP.cpp:465: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x000000001184bf0b 12. /build/src/IO/ReadBuffer.h:60: DB::ReadBuffer::next() @ 0x000000000a148c7b 13. /build/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) @ 0x0000000011849fb2 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]>&)>&, 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&) @ 0x0000000011841980 15. /build/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) @ 0x000000001621208e 16. /build/src/Storages/StorageReplicatedMergeTree.cpp:5228: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl[abi:se190107] const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000015f9a5fe 17. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000015ed8bfd 18. /build/src/Storages/StorageReplicatedMergeTree.cpp:2514: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x0000000015ec9aab 19. /build/src/Storages/StorageReplicatedMergeTree.cpp:2349: DB::StorageReplicatedMergeTree::executeLogEntry(DB::ReplicatedMergeTreeLogEntry&) @ 0x0000000015eba91b 20. /build/src/Storages/StorageReplicatedMergeTree.cpp:3876: bool std::__function::__policy_invoker&)>::__call_impl[abi:se190107])::$_1, bool (std::shared_ptr&)>>(std::__function::__policy_storage const*, std::shared_ptr&) @ 0x0000000015f9837e 21. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000165d6fc3 22. /build/src/Storages/StorageReplicatedMergeTree.cpp:3872: DB::StorageReplicatedMergeTree::processQueueEntry(std::shared_ptr) @ 0x0000000015efc18a 23. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001624c1b2 24. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000162f9c70 25. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x00000000162fa55a 26. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc6653 27. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000000fccc4c3 28. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc3d92 29. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fcca080 30. ? @ 0x00007fbc6213eac3 31. ? @ 0x00007fbc621d0850 (version 25.3.6.10636.altinitytest (altinity build)) 2025.07.28 11:52:50.728839 [ 17252 ] {450f2c05-c545-453c-accf-ff7d20326e4c} executeQuery: Code: 57. DB::Exception: Table test_9.t2 already exists. (TABLE_ALREADY_EXISTS) (version 25.3.6.10636.altinitytest (altinity build)) (from [::1]:34938) (comment: 00604_shard_remote_and_columns_with_defaults.sql) (query 6, line 9) (in query: CREATE TABLE t2(x UInt32, y UInt32 DEFAULT x + 1) ENGINE TinyLog;), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000a06a8eb 4. /build/src/Interpreters/InterpreterCreateQuery.cpp:1824: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x0000000014901d53 5. /build/src/Interpreters/InterpreterCreateQuery.cpp:1743: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000148f9aa9 6. /build/src/Interpreters/InterpreterCreateQuery.cpp:2352: DB::InterpreterCreateQuery::execute() @ 0x0000000014905a41 7. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88dc9 8. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 9. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 10. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 11. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 12. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 13. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 14. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 15. ? @ 0x00007fbc6213eac3 16. ? @ 0x00007fbc621d0850 2025.07.28 11:52:50.735212 [ 3969 ] {} test_13.rmt2 (7f9b740d-015c-470e-8cc6-8ba33be0dc63): auto DB::StorageReplicatedMergeTree::processQueueEntry(ReplicatedMergeTreeQueue::SelectedEntryPtr)::(anonymous class)::operator()(LogEntryPtr &) const: Code: 86. DB::HTTPException: Received error from remote server http://146b4357c08d:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Ftest%2F01165%2Ftest_13%2Frmt%2Freplicas%2F1&part=20250728_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.6.10636.altinitytest (altinity build)) '. (RECEIVED_ERROR_FROM_REMOTE_IO_SERVER), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.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 const&, int&&, String const&, unsigned long&&, String const&) @ 0x000000000feda8d9 4. /build/src/IO/HTTPCommon.cpp:104: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x000000000feda6e2 5. /build/src/IO/HTTPCommon.cpp:93: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x000000000feda537 6. /build/src/IO/ReadWriteBufferFromHTTP.cpp:277: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x000000001184a4c4 7. /build/src/IO/ReadWriteBufferFromHTTP.cpp:285: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x000000001184a615 8. /build/src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x000000001184ae59 9. /build/src/IO/ReadWriteBufferFromHTTP.cpp:472: void std::__function::__policy_invoker::__call_impl[abi:se190107]>(std::__function::__policy_storage const*) @ 0x000000001184cedd 10. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001184858b 11. /build/src/IO/ReadWriteBufferFromHTTP.cpp:465: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x000000001184bf0b 12. /build/src/IO/ReadBuffer.h:60: DB::ReadBuffer::next() @ 0x000000000a148c7b 13. /build/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) @ 0x0000000011849fb2 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]>&)>&, 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&) @ 0x0000000011841980 15. /build/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) @ 0x000000001621208e 16. /build/src/Storages/StorageReplicatedMergeTree.cpp:5228: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl[abi:se190107] const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000015f9a5fe 17. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000015ed8bfd 18. /build/src/Storages/StorageReplicatedMergeTree.cpp:2514: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x0000000015ec9aab 19. /build/src/Storages/StorageReplicatedMergeTree.cpp:2349: DB::StorageReplicatedMergeTree::executeLogEntry(DB::ReplicatedMergeTreeLogEntry&) @ 0x0000000015eba91b 20. /build/src/Storages/StorageReplicatedMergeTree.cpp:3876: bool std::__function::__policy_invoker&)>::__call_impl[abi:se190107])::$_1, bool (std::shared_ptr&)>>(std::__function::__policy_storage const*, std::shared_ptr&) @ 0x0000000015f9837e 21. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000165d6fc3 22. /build/src/Storages/StorageReplicatedMergeTree.cpp:3872: DB::StorageReplicatedMergeTree::processQueueEntry(std::shared_ptr) @ 0x0000000015efc18a 23. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001624c1b2 24. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000162f9c70 25. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x00000000162fa55a 26. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc6653 27. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000000fccc4c3 28. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc3d92 29. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fcca080 30. ? @ 0x00007fbc6213eac3 31. ? @ 0x00007fbc621d0850 (version 25.3.6.10636.altinitytest (altinity build)) 2025.07.28 11:52:50.769783 [ 17252 ] {} TCPHandler: Code: 57. DB::Exception: Table test_9.t2 already exists. (TABLE_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000a06a8eb 4. /build/src/Interpreters/InterpreterCreateQuery.cpp:1824: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x0000000014901d53 5. /build/src/Interpreters/InterpreterCreateQuery.cpp:1743: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000148f9aa9 6. /build/src/Interpreters/InterpreterCreateQuery.cpp:2352: DB::InterpreterCreateQuery::execute() @ 0x0000000014905a41 7. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88dc9 8. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 9. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 10. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 11. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 12. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 13. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 14. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 15. ? @ 0x00007fbc6213eac3 16. ? @ 0x00007fbc621d0850 2025.07.28 11:52:51.287215 [ 17255 ] {3564e0a3-14e4-4924-b458-94375ab0090a} executeQuery: Code: 452. DB::Exception: Setting max_execution_time shouldn't be greater than 60. (SETTING_CONSTRAINT_VIOLATION) (version 25.3.6.10636.altinitytest (altinity build)) (from [::1]:34994) (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. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception>&, String>(int, FormatStringHelperImpl>&>::type, std::type_identity::type>, std::basic_string_view>&, String&&) @ 0x000000001385a5eb 4. /build/src/Access/SettingsConstraints.cpp:376: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000013859b18 5. /build/src/Access/SettingsConstraints.cpp:300: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000013858faf 6. /build/src/Access/SettingsConstraints.cpp:194: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges const&, DB::SettingSource) const @ 0x00000000138591b3 7. /build/src/Interpreters/Context.cpp:2722: DB::Context::checkSettingsConstraints(DB::SettingsChanges const&, DB::SettingSource) @ 0x0000000014436509 8. /build/src/Interpreters/InterpreterSetQuery.cpp:28: DB::InterpreterSetQuery::execute() @ 0x00000000149e240a 9. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88dc9 10. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 11. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 12. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 13. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 14. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 16. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 17. ? @ 0x00007fbc6213eac3 18. ? @ 0x00007fbc621d0850 2025.07.28 11:52:51.328803 [ 17255 ] {} 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. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception>&, String>(int, FormatStringHelperImpl>&>::type, std::type_identity::type>, std::basic_string_view>&, String&&) @ 0x000000001385a5eb 4. /build/src/Access/SettingsConstraints.cpp:376: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000013859b18 5. /build/src/Access/SettingsConstraints.cpp:300: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000013858faf 6. /build/src/Access/SettingsConstraints.cpp:194: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges const&, DB::SettingSource) const @ 0x00000000138591b3 7. /build/src/Interpreters/Context.cpp:2722: DB::Context::checkSettingsConstraints(DB::SettingsChanges const&, DB::SettingSource) @ 0x0000000014436509 8. /build/src/Interpreters/InterpreterSetQuery.cpp:28: DB::InterpreterSetQuery::execute() @ 0x00000000149e240a 9. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88dc9 10. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 11. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 12. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 13. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 14. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 16. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 17. ? @ 0x00007fbc6213eac3 18. ? @ 0x00007fbc621d0850 2025.07.28 11:52:51.422187 [ 3972 ] {} test_13.rmt2 (7f9b740d-015c-470e-8cc6-8ba33be0dc63): auto DB::StorageReplicatedMergeTree::processQueueEntry(ReplicatedMergeTreeQueue::SelectedEntryPtr)::(anonymous class)::operator()(LogEntryPtr &) const: Code: 86. DB::HTTPException: Received error from remote server http://146b4357c08d:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Ftest%2F01165%2Ftest_13%2Frmt%2Freplicas%2F1&part=20250728_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.6.10636.altinitytest (altinity build)) '. (RECEIVED_ERROR_FROM_REMOTE_IO_SERVER), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.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 const&, int&&, String const&, unsigned long&&, String const&) @ 0x000000000feda8d9 4. /build/src/IO/HTTPCommon.cpp:104: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x000000000feda6e2 5. /build/src/IO/HTTPCommon.cpp:93: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x000000000feda537 6. /build/src/IO/ReadWriteBufferFromHTTP.cpp:277: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x000000001184a4c4 7. /build/src/IO/ReadWriteBufferFromHTTP.cpp:285: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x000000001184a615 8. /build/src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x000000001184ae59 9. /build/src/IO/ReadWriteBufferFromHTTP.cpp:472: void std::__function::__policy_invoker::__call_impl[abi:se190107]>(std::__function::__policy_storage const*) @ 0x000000001184cedd 10. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001184858b 11. /build/src/IO/ReadWriteBufferFromHTTP.cpp:465: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x000000001184bf0b 12. /build/src/IO/ReadBuffer.h:60: DB::ReadBuffer::next() @ 0x000000000a148c7b 13. /build/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) @ 0x0000000011849fb2 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]>&)>&, 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&) @ 0x0000000011841980 15. /build/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) @ 0x000000001621208e 16. /build/src/Storages/StorageReplicatedMergeTree.cpp:5228: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl[abi:se190107] const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000015f9a5fe 17. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000015ed8bfd 18. /build/src/Storages/StorageReplicatedMergeTree.cpp:2514: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x0000000015ec9aab 19. /build/src/Storages/StorageReplicatedMergeTree.cpp:2349: DB::StorageReplicatedMergeTree::executeLogEntry(DB::ReplicatedMergeTreeLogEntry&) @ 0x0000000015eba91b 20. /build/src/Storages/StorageReplicatedMergeTree.cpp:3876: bool std::__function::__policy_invoker&)>::__call_impl[abi:se190107])::$_1, bool (std::shared_ptr&)>>(std::__function::__policy_storage const*, std::shared_ptr&) @ 0x0000000015f9837e 21. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000165d6fc3 22. /build/src/Storages/StorageReplicatedMergeTree.cpp:3872: DB::StorageReplicatedMergeTree::processQueueEntry(std::shared_ptr) @ 0x0000000015efc18a 23. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001624c1b2 24. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000162f9c70 25. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x00000000162fa55a 26. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc6653 27. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000000fccc4c3 28. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc3d92 29. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fcca080 30. ? @ 0x00007fbc6213eac3 31. ? @ 0x00007fbc621d0850 (version 25.3.6.10636.altinitytest (altinity build)) 2025.07.28 11:52:52.634384 [ 3962 ] {} test_13.rmt2 (7f9b740d-015c-470e-8cc6-8ba33be0dc63): auto DB::StorageReplicatedMergeTree::processQueueEntry(ReplicatedMergeTreeQueue::SelectedEntryPtr)::(anonymous class)::operator()(LogEntryPtr &) const: Code: 86. DB::HTTPException: Received error from remote server http://146b4357c08d:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Ftest%2F01165%2Ftest_13%2Frmt%2Freplicas%2F1&part=20250728_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.6.10636.altinitytest (altinity build)) '. (RECEIVED_ERROR_FROM_REMOTE_IO_SERVER), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.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 const&, int&&, String const&, unsigned long&&, String const&) @ 0x000000000feda8d9 4. /build/src/IO/HTTPCommon.cpp:104: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x000000000feda6e2 5. /build/src/IO/HTTPCommon.cpp:93: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x000000000feda537 6. /build/src/IO/ReadWriteBufferFromHTTP.cpp:277: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x000000001184a4c4 7. /build/src/IO/ReadWriteBufferFromHTTP.cpp:285: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x000000001184a615 8. /build/src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x000000001184ae59 9. /build/src/IO/ReadWriteBufferFromHTTP.cpp:472: void std::__function::__policy_invoker::__call_impl[abi:se190107]>(std::__function::__policy_storage const*) @ 0x000000001184cedd 10. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001184858b 11. /build/src/IO/ReadWriteBufferFromHTTP.cpp:465: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x000000001184bf0b 12. /build/src/IO/ReadBuffer.h:60: DB::ReadBuffer::next() @ 0x000000000a148c7b 13. /build/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) @ 0x0000000011849fb2 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]>&)>&, 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&) @ 0x0000000011841980 15. /build/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) @ 0x000000001621208e 16. /build/src/Storages/StorageReplicatedMergeTree.cpp:5228: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl[abi:se190107] const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000015f9a5fe 17. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000015ed8bfd 18. /build/src/Storages/StorageReplicatedMergeTree.cpp:2514: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x0000000015ec9aab 19. /build/src/Storages/StorageReplicatedMergeTree.cpp:2349: DB::StorageReplicatedMergeTree::executeLogEntry(DB::ReplicatedMergeTreeLogEntry&) @ 0x0000000015eba91b 20. /build/src/Storages/StorageReplicatedMergeTree.cpp:3876: bool std::__function::__policy_invoker&)>::__call_impl[abi:se190107])::$_1, bool (std::shared_ptr&)>>(std::__function::__policy_storage const*, std::shared_ptr&) @ 0x0000000015f9837e 21. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000165d6fc3 22. /build/src/Storages/StorageReplicatedMergeTree.cpp:3872: DB::StorageReplicatedMergeTree::processQueueEntry(std::shared_ptr) @ 0x0000000015efc18a 23. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001624c1b2 24. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000162f9c70 25. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x00000000162fa55a 26. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc6653 27. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000000fccc4c3 28. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc3d92 29. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fcca080 30. ? @ 0x00007fbc6213eac3 31. ? @ 0x00007fbc621d0850 (version 25.3.6.10636.altinitytest (altinity build)) 2025.07.28 11:52:52.647277 [ 17251 ] {} 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. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception>&, String>(int, FormatStringHelperImpl>&>::type, std::type_identity::type>, std::basic_string_view>&, String&&) @ 0x000000001385a5eb 4. /build/src/Access/SettingsConstraints.cpp:376: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000013859b18 5. /build/src/Access/SettingsConstraints.cpp:300: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000013858faf 6. /build/src/Access/SettingsConstraints.cpp:209: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000013859223 7. /build/src/Interpreters/Context.cpp:2690: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000014436134 8. /build/src/Interpreters/Context.cpp:2729: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x000000001443662b 9. /build/src/Server/HTTPHandler.cpp:457: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000001686d165 10. /build/src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x0000000016870807 11. /build/src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x0000000016907e99 12. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 13. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 14. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 15. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 16. ? @ 0x00007fbc6213eac3 17. ? @ 0x00007fbc621d0850 (version 25.3.6.10636.altinitytest (altinity build)) 2025.07.28 11:52:53.170479 [ 3963 ] {} test_13.rmt2 (7f9b740d-015c-470e-8cc6-8ba33be0dc63): auto DB::StorageReplicatedMergeTree::processQueueEntry(ReplicatedMergeTreeQueue::SelectedEntryPtr)::(anonymous class)::operator()(LogEntryPtr &) const: Code: 86. DB::HTTPException: Received error from remote server http://146b4357c08d:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Ftest%2F01165%2Ftest_13%2Frmt%2Freplicas%2F1&part=20250728_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.6.10636.altinitytest (altinity build)) '. (RECEIVED_ERROR_FROM_REMOTE_IO_SERVER), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.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 const&, int&&, String const&, unsigned long&&, String const&) @ 0x000000000feda8d9 4. /build/src/IO/HTTPCommon.cpp:104: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x000000000feda6e2 5. /build/src/IO/HTTPCommon.cpp:93: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x000000000feda537 6. /build/src/IO/ReadWriteBufferFromHTTP.cpp:277: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x000000001184a4c4 7. /build/src/IO/ReadWriteBufferFromHTTP.cpp:285: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x000000001184a615 8. /build/src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x000000001184ae59 9. /build/src/IO/ReadWriteBufferFromHTTP.cpp:472: void std::__function::__policy_invoker::__call_impl[abi:se190107]>(std::__function::__policy_storage const*) @ 0x000000001184cedd 10. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001184858b 11. /build/src/IO/ReadWriteBufferFromHTTP.cpp:465: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x000000001184bf0b 12. /build/src/IO/ReadBuffer.h:60: DB::ReadBuffer::next() @ 0x000000000a148c7b 13. /build/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) @ 0x0000000011849fb2 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]>&)>&, 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&) @ 0x0000000011841980 15. /build/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) @ 0x000000001621208e 16. /build/src/Storages/StorageReplicatedMergeTree.cpp:5228: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl[abi:se190107] const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000015f9a5fe 17. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000015ed8bfd 18. /build/src/Storages/StorageReplicatedMergeTree.cpp:2514: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x0000000015ec9aab 19. /build/src/Storages/StorageReplicatedMergeTree.cpp:2349: DB::StorageReplicatedMergeTree::executeLogEntry(DB::ReplicatedMergeTreeLogEntry&) @ 0x0000000015eba91b 20. /build/src/Storages/StorageReplicatedMergeTree.cpp:3876: bool std::__function::__policy_invoker&)>::__call_impl[abi:se190107])::$_1, bool (std::shared_ptr&)>>(std::__function::__policy_storage const*, std::shared_ptr&) @ 0x0000000015f9837e 21. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000165d6fc3 22. /build/src/Storages/StorageReplicatedMergeTree.cpp:3872: DB::StorageReplicatedMergeTree::processQueueEntry(std::shared_ptr) @ 0x0000000015efc18a 23. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001624c1b2 24. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000162f9c70 25. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x00000000162fa55a 26. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc6653 27. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000000fccc4c3 28. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc3d92 29. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fcca080 30. ? @ 0x00007fbc6213eac3 31. ? @ 0x00007fbc621d0850 (version 25.3.6.10636.altinitytest (altinity build)) 2025.07.28 11:52:53.869060 [ 17611 ] {592bb87d-d531-4672-83f3-9dff7a54e9cb} executeQuery: Code: 36. DB::Exception: Wrong JSON string to merge. Expected JSON object: In scope SELECT jsonMergePatch('[1]'). (BAD_ARGUMENTS) (version 25.3.6.10636.altinitytest (altinity build)) (from [::1]:47346) (comment: 02874_json_merge_patch_function_test.sql) (query 11, line 13) (in query: select jsonMergePatch('[1]');), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000000a074fcb 4. /build/src/Functions/jsonMergePatch.cpp:108: DB::(anonymous namespace)::FunctionJSONMergePatch::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(DB::ColumnString const&, rapidjson::GenericDocument, rapidjson::MemoryPoolAllocator, rapidjson::CrtAllocator>&, unsigned long)::operator()(DB::ColumnString const&, rapidjson::GenericDocument, rapidjson::MemoryPoolAllocator, rapidjson::CrtAllocator>&, unsigned long) const @ 0x000000000c7f4843 5. /build/src/Functions/jsonMergePatch.cpp:0: DB::(anonymous namespace)::FunctionJSONMergePatch::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000c7f3a86 6. /build/src/Functions/IFunction.h:437: DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000a069f2a 7. /build/src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000012d9965a 8. /build/src/Functions/IFunction.cpp:351: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d93b02 9. /build/src/Functions/IFunction.cpp:177: DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d93698 10. /build/src/Functions/IFunction.cpp:343: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d93aad 11. /build/src/Functions/IFunction.cpp:420: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d95059 12. /build/src/Functions/IFunction.cpp:498: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d95c72 13. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3567: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000014034494 14. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3838: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000014019a9e 15. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3980: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000014018e31 16. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:4304: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000014042fa7 17. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5605: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000014013749 18. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000140127f9 19. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000014011fce 20. /build/src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000001406ce8a 21. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000014973b42 22. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000001497268d 23. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000014974d24 24. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001492924b 25. /build/src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88641 26. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 27. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 28. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 29. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 30. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 31. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 2025.07.28 11:52:53.874225 [ 17611 ] {} TCPHandler: Code: 36. DB::Exception: Wrong JSON string to merge. Expected JSON object: In scope SELECT jsonMergePatch('[1]'). (BAD_ARGUMENTS), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000000a074fcb 4. /build/src/Functions/jsonMergePatch.cpp:108: DB::(anonymous namespace)::FunctionJSONMergePatch::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(DB::ColumnString const&, rapidjson::GenericDocument, rapidjson::MemoryPoolAllocator, rapidjson::CrtAllocator>&, unsigned long)::operator()(DB::ColumnString const&, rapidjson::GenericDocument, rapidjson::MemoryPoolAllocator, rapidjson::CrtAllocator>&, unsigned long) const @ 0x000000000c7f4843 5. /build/src/Functions/jsonMergePatch.cpp:0: DB::(anonymous namespace)::FunctionJSONMergePatch::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000c7f3a86 6. /build/src/Functions/IFunction.h:437: DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000a069f2a 7. /build/src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000012d9965a 8. /build/src/Functions/IFunction.cpp:351: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d93b02 9. /build/src/Functions/IFunction.cpp:177: DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d93698 10. /build/src/Functions/IFunction.cpp:343: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d93aad 11. /build/src/Functions/IFunction.cpp:420: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d95059 12. /build/src/Functions/IFunction.cpp:498: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d95c72 13. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3567: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000014034494 14. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3838: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000014019a9e 15. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3980: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000014018e31 16. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:4304: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000014042fa7 17. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5605: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000014013749 18. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000140127f9 19. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000014011fce 20. /build/src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000001406ce8a 21. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000014973b42 22. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000001497268d 23. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000014974d24 24. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001492924b 25. /build/src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88641 26. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 27. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 28. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 29. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 30. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 31. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 2025.07.28 11:52:54.037938 [ 17611 ] {616dd423-3845-4c9f-8d08-cfd03d6d469f} executeQuery: Code: 36. DB::Exception: Wrong JSON string to merge: Missing a comma or ']' after an array element.: In scope SELECT jsonMergePatch('{"a": "1","b": 2,"c": [true,"qrdzkzjvnos": true,"yxqhipj": false,"oesax": "33o8_6AyUy"}]}', '{"c": "1"}'). (BAD_ARGUMENTS) (version 25.3.6.10636.altinitytest (altinity build)) (from [::1]:47346) (comment: 02874_json_merge_patch_function_test.sql) (query 12, line 14) (in query: select jsonMergePatch('{"a": "1","b": 2,"c": [true,"qrdzkzjvnos": true,"yxqhipj": false,"oesax": "33o8_6AyUy"}]}', '{"c": "1"}');), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type>, char const*&&) @ 0x000000000c7f5eab 4. /build/src/Functions/jsonMergePatch.cpp:105: DB::(anonymous namespace)::FunctionJSONMergePatch::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(DB::ColumnString const&, rapidjson::GenericDocument, rapidjson::MemoryPoolAllocator, rapidjson::CrtAllocator>&, unsigned long)::operator()(DB::ColumnString const&, rapidjson::GenericDocument, rapidjson::MemoryPoolAllocator, rapidjson::CrtAllocator>&, unsigned long) const @ 0x000000000c7f47d6 5. /build/src/Functions/jsonMergePatch.cpp:0: DB::(anonymous namespace)::FunctionJSONMergePatch::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000c7f3a86 6. /build/src/Functions/IFunction.h:437: DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000a069f2a 7. /build/src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000012d9965a 8. /build/src/Functions/IFunction.cpp:351: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d93b02 9. /build/src/Functions/IFunction.cpp:177: DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d93698 10. /build/src/Functions/IFunction.cpp:343: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d93aad 11. /build/src/Functions/IFunction.cpp:420: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d95059 12. /build/src/Functions/IFunction.cpp:498: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d95c72 13. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3567: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000014034494 14. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3838: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000014019a9e 15. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3980: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000014018e31 16. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:4304: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000014042fa7 17. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5605: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000014013749 18. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000140127f9 19. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000014011fce 20. /build/src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000001406ce8a 21. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000014973b42 22. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000001497268d 23. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000014974d24 24. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001492924b 25. /build/src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88641 26. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 27. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 28. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 29. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 30. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 31. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 2025.07.28 11:52:54.045449 [ 17611 ] {} TCPHandler: Code: 36. DB::Exception: Wrong JSON string to merge: Missing a comma or ']' after an array element.: In scope SELECT jsonMergePatch('{"a": "1","b": 2,"c": [true,"qrdzkzjvnos": true,"yxqhipj": false,"oesax": "33o8_6AyUy"}]}', '{"c": "1"}'). (BAD_ARGUMENTS), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type>, char const*&&) @ 0x000000000c7f5eab 4. /build/src/Functions/jsonMergePatch.cpp:105: DB::(anonymous namespace)::FunctionJSONMergePatch::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(DB::ColumnString const&, rapidjson::GenericDocument, rapidjson::MemoryPoolAllocator, rapidjson::CrtAllocator>&, unsigned long)::operator()(DB::ColumnString const&, rapidjson::GenericDocument, rapidjson::MemoryPoolAllocator, rapidjson::CrtAllocator>&, unsigned long) const @ 0x000000000c7f47d6 5. /build/src/Functions/jsonMergePatch.cpp:0: DB::(anonymous namespace)::FunctionJSONMergePatch::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000c7f3a86 6. /build/src/Functions/IFunction.h:437: DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000a069f2a 7. /build/src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000012d9965a 8. /build/src/Functions/IFunction.cpp:351: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d93b02 9. /build/src/Functions/IFunction.cpp:177: DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d93698 10. /build/src/Functions/IFunction.cpp:343: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d93aad 11. /build/src/Functions/IFunction.cpp:420: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d95059 12. /build/src/Functions/IFunction.cpp:498: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d95c72 13. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3567: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000014034494 14. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3838: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000014019a9e 15. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3980: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000014018e31 16. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:4304: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000014042fa7 17. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5605: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000014013749 18. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000140127f9 19. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000014011fce 20. /build/src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000001406ce8a 21. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000014973b42 22. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000001497268d 23. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000014974d24 24. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001492924b 25. /build/src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88641 26. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 27. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 28. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 29. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 30. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 31. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 2025.07.28 11:52:54.134515 [ 3974 ] {} test_13.rmt2 (7f9b740d-015c-470e-8cc6-8ba33be0dc63): auto DB::StorageReplicatedMergeTree::processQueueEntry(ReplicatedMergeTreeQueue::SelectedEntryPtr)::(anonymous class)::operator()(LogEntryPtr &) const: Code: 86. DB::HTTPException: Received error from remote server http://146b4357c08d:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Ftest%2F01165%2Ftest_13%2Frmt%2Freplicas%2F1&part=20250728_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.6.10636.altinitytest (altinity build)) '. (RECEIVED_ERROR_FROM_REMOTE_IO_SERVER), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.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 const&, int&&, String const&, unsigned long&&, String const&) @ 0x000000000feda8d9 4. /build/src/IO/HTTPCommon.cpp:104: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x000000000feda6e2 5. /build/src/IO/HTTPCommon.cpp:93: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x000000000feda537 6. /build/src/IO/ReadWriteBufferFromHTTP.cpp:277: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x000000001184a4c4 7. /build/src/IO/ReadWriteBufferFromHTTP.cpp:285: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x000000001184a615 8. /build/src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x000000001184ae59 9. /build/src/IO/ReadWriteBufferFromHTTP.cpp:472: void std::__function::__policy_invoker::__call_impl[abi:se190107]>(std::__function::__policy_storage const*) @ 0x000000001184cedd 10. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001184858b 11. /build/src/IO/ReadWriteBufferFromHTTP.cpp:465: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x000000001184bf0b 12. /build/src/IO/ReadBuffer.h:60: DB::ReadBuffer::next() @ 0x000000000a148c7b 13. /build/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) @ 0x0000000011849fb2 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]>&)>&, 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&) @ 0x0000000011841980 15. /build/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) @ 0x000000001621208e 16. /build/src/Storages/StorageReplicatedMergeTree.cpp:5228: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl[abi:se190107] const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000015f9a5fe 17. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000015ed8bfd 18. /build/src/Storages/StorageReplicatedMergeTree.cpp:2514: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x0000000015ec9aab 19. /build/src/Storages/StorageReplicatedMergeTree.cpp:2349: DB::StorageReplicatedMergeTree::executeLogEntry(DB::ReplicatedMergeTreeLogEntry&) @ 0x0000000015eba91b 20. /build/src/Storages/StorageReplicatedMergeTree.cpp:3876: bool std::__function::__policy_invoker&)>::__call_impl[abi:se190107])::$_1, bool (std::shared_ptr&)>>(std::__function::__policy_storage const*, std::shared_ptr&) @ 0x0000000015f9837e 21. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000165d6fc3 22. /build/src/Storages/StorageReplicatedMergeTree.cpp:3872: DB::StorageReplicatedMergeTree::processQueueEntry(std::shared_ptr) @ 0x0000000015efc18a 23. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001624c1b2 24. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000162f9c70 25. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x00000000162fa55a 26. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc6653 27. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000000fccc4c3 28. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc3d92 29. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fcca080 30. ? @ 0x00007fbc6213eac3 31. ? @ 0x00007fbc621d0850 (version 25.3.6.10636.altinitytest (altinity build)) 2025.07.28 11:52:54.535307 [ 3976 ] {} test_13.rmt2 (7f9b740d-015c-470e-8cc6-8ba33be0dc63): auto DB::StorageReplicatedMergeTree::processQueueEntry(ReplicatedMergeTreeQueue::SelectedEntryPtr)::(anonymous class)::operator()(LogEntryPtr &) const: Code: 86. DB::HTTPException: Received error from remote server http://146b4357c08d:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Ftest%2F01165%2Ftest_13%2Frmt%2Freplicas%2F1&part=20250728_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.6.10636.altinitytest (altinity build)) '. (RECEIVED_ERROR_FROM_REMOTE_IO_SERVER), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.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 const&, int&&, String const&, unsigned long&&, String const&) @ 0x000000000feda8d9 4. /build/src/IO/HTTPCommon.cpp:104: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x000000000feda6e2 5. /build/src/IO/HTTPCommon.cpp:93: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x000000000feda537 6. /build/src/IO/ReadWriteBufferFromHTTP.cpp:277: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x000000001184a4c4 7. /build/src/IO/ReadWriteBufferFromHTTP.cpp:285: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x000000001184a615 8. /build/src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x000000001184ae59 9. /build/src/IO/ReadWriteBufferFromHTTP.cpp:472: void std::__function::__policy_invoker::__call_impl[abi:se190107]>(std::__function::__policy_storage const*) @ 0x000000001184cedd 10. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001184858b 11. /build/src/IO/ReadWriteBufferFromHTTP.cpp:465: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x000000001184bf0b 12. /build/src/IO/ReadBuffer.h:60: DB::ReadBuffer::next() @ 0x000000000a148c7b 13. /build/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) @ 0x0000000011849fb2 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]>&)>&, 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&) @ 0x0000000011841980 15. /build/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) @ 0x000000001621208e 16. /build/src/Storages/StorageReplicatedMergeTree.cpp:5228: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl[abi:se190107] const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000015f9a5fe 17. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000015ed8bfd 18. /build/src/Storages/StorageReplicatedMergeTree.cpp:2514: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x0000000015ec9aab 19. /build/src/Storages/StorageReplicatedMergeTree.cpp:2349: DB::StorageReplicatedMergeTree::executeLogEntry(DB::ReplicatedMergeTreeLogEntry&) @ 0x0000000015eba91b 20. /build/src/Storages/StorageReplicatedMergeTree.cpp:3876: bool std::__function::__policy_invoker&)>::__call_impl[abi:se190107])::$_1, bool (std::shared_ptr&)>>(std::__function::__policy_storage const*, std::shared_ptr&) @ 0x0000000015f9837e 21. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000165d6fc3 22. /build/src/Storages/StorageReplicatedMergeTree.cpp:3872: DB::StorageReplicatedMergeTree::processQueueEntry(std::shared_ptr) @ 0x0000000015efc18a 23. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001624c1b2 24. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000162f9c70 25. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x00000000162fa55a 26. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc6653 27. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000000fccc4c3 28. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc3d92 29. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fcca080 30. ? @ 0x00007fbc6213eac3 31. ? @ 0x00007fbc621d0850 (version 25.3.6.10636.altinitytest (altinity build)) 2025.07.28 11:52:55.466441 [ 3970 ] {} test_13.rmt2 (7f9b740d-015c-470e-8cc6-8ba33be0dc63): auto DB::StorageReplicatedMergeTree::processQueueEntry(ReplicatedMergeTreeQueue::SelectedEntryPtr)::(anonymous class)::operator()(LogEntryPtr &) const: Code: 86. DB::HTTPException: Received error from remote server http://146b4357c08d:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Ftest%2F01165%2Ftest_13%2Frmt%2Freplicas%2F1&part=20250728_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.6.10636.altinitytest (altinity build)) '. (RECEIVED_ERROR_FROM_REMOTE_IO_SERVER), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.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 const&, int&&, String const&, unsigned long&&, String const&) @ 0x000000000feda8d9 4. /build/src/IO/HTTPCommon.cpp:104: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x000000000feda6e2 5. /build/src/IO/HTTPCommon.cpp:93: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x000000000feda537 6. /build/src/IO/ReadWriteBufferFromHTTP.cpp:277: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x000000001184a4c4 7. /build/src/IO/ReadWriteBufferFromHTTP.cpp:285: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x000000001184a615 8. /build/src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x000000001184ae59 9. /build/src/IO/ReadWriteBufferFromHTTP.cpp:472: void std::__function::__policy_invoker::__call_impl[abi:se190107]>(std::__function::__policy_storage const*) @ 0x000000001184cedd 10. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001184858b 11. /build/src/IO/ReadWriteBufferFromHTTP.cpp:465: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x000000001184bf0b 12. /build/src/IO/ReadBuffer.h:60: DB::ReadBuffer::next() @ 0x000000000a148c7b 13. /build/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) @ 0x0000000011849fb2 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]>&)>&, 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&) @ 0x0000000011841980 15. /build/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) @ 0x000000001621208e 16. /build/src/Storages/StorageReplicatedMergeTree.cpp:5228: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl[abi:se190107] const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000015f9a5fe 17. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000015ed8bfd 18. /build/src/Storages/StorageReplicatedMergeTree.cpp:2514: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x0000000015ec9aab 19. /build/src/Storages/StorageReplicatedMergeTree.cpp:2349: DB::StorageReplicatedMergeTree::executeLogEntry(DB::ReplicatedMergeTreeLogEntry&) @ 0x0000000015eba91b 20. /build/src/Storages/StorageReplicatedMergeTree.cpp:3876: bool std::__function::__policy_invoker&)>::__call_impl[abi:se190107])::$_1, bool (std::shared_ptr&)>>(std::__function::__policy_storage const*, std::shared_ptr&) @ 0x0000000015f9837e 21. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000165d6fc3 22. /build/src/Storages/StorageReplicatedMergeTree.cpp:3872: DB::StorageReplicatedMergeTree::processQueueEntry(std::shared_ptr) @ 0x0000000015efc18a 23. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001624c1b2 24. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000162f9c70 25. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x00000000162fa55a 26. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc6653 27. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000000fccc4c3 28. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc3d92 29. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fcca080 30. ? @ 0x00007fbc6213eac3 31. ? @ 0x00007fbc621d0850 (version 25.3.6.10636.altinitytest (altinity build)) 2025.07.28 11:52:56.042444 [ 3965 ] {} test_13.rmt2 (7f9b740d-015c-470e-8cc6-8ba33be0dc63): auto DB::StorageReplicatedMergeTree::processQueueEntry(ReplicatedMergeTreeQueue::SelectedEntryPtr)::(anonymous class)::operator()(LogEntryPtr &) const: Code: 86. DB::HTTPException: Received error from remote server http://146b4357c08d:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Ftest%2F01165%2Ftest_13%2Frmt%2Freplicas%2F1&part=20250728_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.6.10636.altinitytest (altinity build)) '. (RECEIVED_ERROR_FROM_REMOTE_IO_SERVER), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.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 const&, int&&, String const&, unsigned long&&, String const&) @ 0x000000000feda8d9 4. /build/src/IO/HTTPCommon.cpp:104: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x000000000feda6e2 5. /build/src/IO/HTTPCommon.cpp:93: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x000000000feda537 6. /build/src/IO/ReadWriteBufferFromHTTP.cpp:277: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x000000001184a4c4 7. /build/src/IO/ReadWriteBufferFromHTTP.cpp:285: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x000000001184a615 8. /build/src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x000000001184ae59 9. /build/src/IO/ReadWriteBufferFromHTTP.cpp:472: void std::__function::__policy_invoker::__call_impl[abi:se190107]>(std::__function::__policy_storage const*) @ 0x000000001184cedd 10. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001184858b 11. /build/src/IO/ReadWriteBufferFromHTTP.cpp:465: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x000000001184bf0b 12. /build/src/IO/ReadBuffer.h:60: DB::ReadBuffer::next() @ 0x000000000a148c7b 13. /build/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) @ 0x0000000011849fb2 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]>&)>&, 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&) @ 0x0000000011841980 15. /build/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) @ 0x000000001621208e 16. /build/src/Storages/StorageReplicatedMergeTree.cpp:5228: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl[abi:se190107] const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000015f9a5fe 17. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000015ed8bfd 18. /build/src/Storages/StorageReplicatedMergeTree.cpp:2514: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x0000000015ec9aab 19. /build/src/Storages/StorageReplicatedMergeTree.cpp:2349: DB::StorageReplicatedMergeTree::executeLogEntry(DB::ReplicatedMergeTreeLogEntry&) @ 0x0000000015eba91b 20. /build/src/Storages/StorageReplicatedMergeTree.cpp:3876: bool std::__function::__policy_invoker&)>::__call_impl[abi:se190107])::$_1, bool (std::shared_ptr&)>>(std::__function::__policy_storage const*, std::shared_ptr&) @ 0x0000000015f9837e 21. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000165d6fc3 22. /build/src/Storages/StorageReplicatedMergeTree.cpp:3872: DB::StorageReplicatedMergeTree::processQueueEntry(std::shared_ptr) @ 0x0000000015efc18a 23. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001624c1b2 24. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000162f9c70 25. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x00000000162fa55a 26. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc6653 27. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000000fccc4c3 28. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc3d92 29. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fcca080 30. ? @ 0x00007fbc6213eac3 31. ? @ 0x00007fbc621d0850 (version 25.3.6.10636.altinitytest (altinity build)) 2025.07.28 11:52:56.215810 [ 17611 ] {bdc689da-af1f-4124-93c7-bbde4abdd953} executeQuery: Code: 47. DB::Exception: Unknown expression or function identifier `x` in scope x = 1. Maybe you meant: ['c']. (UNKNOWN_IDENTIFIER) (version 25.3.6.10636.altinitytest (altinity build)) (from [::1]:47440) (comment: 02902_json_skip_null_values.sql) (query 2, line 8) (in query: select * from test_02902 format JSONEachRow settings output_format_json_named_tuples_as_objects = 1, output_format_json_skip_null_value_in_named_tuples = 1;), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.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&&) @ 0x000000001404b3b9 4. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3771: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000001401b849 5. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3980: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000014018e31 6. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:2925: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000001402fcbd 7. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3838: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000014019a9e 8. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:209: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000001401270e 9. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000014011fce 10. /build/src/Planner/Utils.cpp:458: DB::buildFilterInfo(std::shared_ptr, std::shared_ptr const&, std::shared_ptr&, std::unordered_set, std::equal_to, std::allocator>) @ 0x0000000013fe8bcf 11. /build/src/Planner/PlannerJoinTree.cpp:535: DB::(anonymous namespace)::buildQueryPlanForTableExpression(std::shared_ptr, std::shared_ptr const&, DB::SelectQueryInfo const&, DB::SelectQueryOptions const&, std::shared_ptr&, bool, bool) @ 0x00000000149956d3 12. /build/src/Planner/PlannerJoinTree.cpp:2252: DB::buildJoinTreeQueryPlan(std::shared_ptr const&, DB::SelectQueryInfo const&, DB::SelectQueryOptions&, std::unordered_set, std::equal_to, std::allocator> const&, std::shared_ptr&) @ 0x000000001498e109 13. /build/src/Planner/Planner.cpp:1553: DB::Planner::buildPlanForQueryNode() @ 0x0000000014979dae 14. /build/src/Planner/Planner.cpp:1308: DB::Planner::buildQueryPlanIfNeeded() @ 0x000000001497685c 15. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:255: DB::InterpreterSelectQueryAnalyzer::getQueryPlan() @ 0x000000001497476d 16. /build/src/Interpreters/executeQuery.cpp:1405: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88806 17. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 18. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 19. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 20. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 21. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 22. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 23. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 24. ? @ 0x00007fbc6213eac3 25. ? @ 0x00007fbc621d0850 2025.07.28 11:52:56.218284 [ 17611 ] {} TCPHandler: Code: 47. DB::Exception: Unknown expression or function identifier `x` in scope x = 1. Maybe you meant: ['c']. (UNKNOWN_IDENTIFIER), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.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&&) @ 0x000000001404b3b9 4. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3771: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000001401b849 5. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3980: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000014018e31 6. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:2925: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000001402fcbd 7. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3838: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000014019a9e 8. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:209: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000001401270e 9. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000014011fce 10. /build/src/Planner/Utils.cpp:458: DB::buildFilterInfo(std::shared_ptr, std::shared_ptr const&, std::shared_ptr&, std::unordered_set, std::equal_to, std::allocator>) @ 0x0000000013fe8bcf 11. /build/src/Planner/PlannerJoinTree.cpp:535: DB::(anonymous namespace)::buildQueryPlanForTableExpression(std::shared_ptr, std::shared_ptr const&, DB::SelectQueryInfo const&, DB::SelectQueryOptions const&, std::shared_ptr&, bool, bool) @ 0x00000000149956d3 12. /build/src/Planner/PlannerJoinTree.cpp:2252: DB::buildJoinTreeQueryPlan(std::shared_ptr const&, DB::SelectQueryInfo const&, DB::SelectQueryOptions&, std::unordered_set, std::equal_to, std::allocator> const&, std::shared_ptr&) @ 0x000000001498e109 13. /build/src/Planner/Planner.cpp:1553: DB::Planner::buildPlanForQueryNode() @ 0x0000000014979dae 14. /build/src/Planner/Planner.cpp:1308: DB::Planner::buildQueryPlanIfNeeded() @ 0x000000001497685c 15. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:255: DB::InterpreterSelectQueryAnalyzer::getQueryPlan() @ 0x000000001497476d 16. /build/src/Interpreters/executeQuery.cpp:1405: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88806 17. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 18. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 19. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 20. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 21. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 22. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 23. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 24. ? @ 0x00007fbc6213eac3 25. ? @ 0x00007fbc621d0850 2025.07.28 11:52:56.836627 [ 17207 ] {c88d86d9-1bf7-43f8-8834-04c687184b57} PushingToViews: Failed to push block to view test_5.v2 (7c22a887-3ed3-40f1-a092-d92463e4b87b), Stack size too large. Stack address: 0x7fb7fddf0000, frame address: 0x7fb7fe1ef100, stack size: 4198144, maximum stack size: 8388608 2025.07.28 11:52:56.842107 [ 17207 ] {c88d86d9-1bf7-43f8-8834-04c687184b57} PushingToViews: Failed to push block to view test_5.v1 (4ae2feef-b6fa-47ac-b20c-744da14b2a0a), Stack size too large. Stack address: 0x7fb7fddf0000, frame address: 0x7fb7fe1ef100, stack size: 4198144, maximum stack size: 8388608 2025.07.28 11:52:56.848590 [ 17207 ] {c88d86d9-1bf7-43f8-8834-04c687184b57} PushingToViews: Failed to push block to view test_5.v2 (7c22a887-3ed3-40f1-a092-d92463e4b87b), Stack size too large. Stack address: 0x7fb7fddf0000, frame address: 0x7fb7fe1ef100, stack size: 4198144, maximum stack size: 8388608 2025.07.28 11:52:56.855405 [ 17207 ] {c88d86d9-1bf7-43f8-8834-04c687184b57} PushingToViews: Failed to push block to view test_5.v1 (4ae2feef-b6fa-47ac-b20c-744da14b2a0a), Stack size too large. Stack address: 0x7fb7fddf0000, frame address: 0x7fb7fe1ef100, stack size: 4198144, maximum stack size: 8388608 2025.07.28 11:52:56.859690 [ 17207 ] {c88d86d9-1bf7-43f8-8834-04c687184b57} PushingToViews: Failed to push block to view test_5.v2 (7c22a887-3ed3-40f1-a092-d92463e4b87b), Stack size too large. Stack address: 0x7fb7fddf0000, frame address: 0x7fb7fe1ef100, stack size: 4198144, maximum stack size: 8388608 2025.07.28 11:52:56.861091 [ 17207 ] {c88d86d9-1bf7-43f8-8834-04c687184b57} PushingToViews: Failed to push block to view test_5.v1 (4ae2feef-b6fa-47ac-b20c-744da14b2a0a), Stack size too large. Stack address: 0x7fb7fddf0000, frame address: 0x7fb7fe1ef100, stack size: 4198144, maximum stack size: 8388608 2025.07.28 11:52:56.863219 [ 17207 ] {c88d86d9-1bf7-43f8-8834-04c687184b57} PushingToViews: Failed to push block to view test_5.v2 (7c22a887-3ed3-40f1-a092-d92463e4b87b), Stack size too large. Stack address: 0x7fb7fddf0000, frame address: 0x7fb7fe1ef100, stack size: 4198144, maximum stack size: 8388608 2025.07.28 11:52:56.864438 [ 17207 ] {c88d86d9-1bf7-43f8-8834-04c687184b57} PushingToViews: Failed to push block to view test_5.v1 (4ae2feef-b6fa-47ac-b20c-744da14b2a0a), Stack size too large. Stack address: 0x7fb7fddf0000, frame address: 0x7fb7fe1ef100, stack size: 4198144, maximum stack size: 8388608 2025.07.28 11:52:56.868928 [ 17207 ] {c88d86d9-1bf7-43f8-8834-04c687184b57} PushingToViews: Failed to push block to view test_5.v2 (7c22a887-3ed3-40f1-a092-d92463e4b87b), Stack size too large. Stack address: 0x7fb7fddf0000, frame address: 0x7fb7fe1ef100, stack size: 4198144, maximum stack size: 8388608 2025.07.28 11:52:56.869870 [ 17207 ] {c88d86d9-1bf7-43f8-8834-04c687184b57} PushingToViews: Failed to push block to view test_5.v1 (4ae2feef-b6fa-47ac-b20c-744da14b2a0a), Stack size too large. Stack address: 0x7fb7fddf0000, frame address: 0x7fb7fe1ef100, stack size: 4198144, maximum stack size: 8388608 2025.07.28 11:52:56.872223 [ 17207 ] {c88d86d9-1bf7-43f8-8834-04c687184b57} PushingToViews: Failed to push block to view test_5.v2 (7c22a887-3ed3-40f1-a092-d92463e4b87b), Stack size too large. Stack address: 0x7fb7fddf0000, frame address: 0x7fb7fe1ef100, stack size: 4198144, maximum stack size: 8388608 2025.07.28 11:52:56.874504 [ 17207 ] {c88d86d9-1bf7-43f8-8834-04c687184b57} PushingToViews: Failed to push block to view test_5.v1 (4ae2feef-b6fa-47ac-b20c-744da14b2a0a), Stack size too large. Stack address: 0x7fb7fddf0000, frame address: 0x7fb7fe1ef100, stack size: 4198144, maximum stack size: 8388608 2025.07.28 11:52:56.876137 [ 17207 ] {c88d86d9-1bf7-43f8-8834-04c687184b57} PushingToViews: Failed to push block to view test_5.v2 (7c22a887-3ed3-40f1-a092-d92463e4b87b), Stack size too large. Stack address: 0x7fb7fddf0000, frame address: 0x7fb7fe1ef100, stack size: 4198144, maximum stack size: 8388608 2025.07.28 11:52:56.878062 [ 17207 ] {c88d86d9-1bf7-43f8-8834-04c687184b57} PushingToViews: Failed to push block to view test_5.v1 (4ae2feef-b6fa-47ac-b20c-744da14b2a0a), Stack size too large. Stack address: 0x7fb7fddf0000, frame address: 0x7fb7fe1ef100, stack size: 4198144, maximum stack size: 8388608 2025.07.28 11:52:56.884688 [ 17207 ] {c88d86d9-1bf7-43f8-8834-04c687184b57} PushingToViews: Failed to push block to view test_5.v2 (7c22a887-3ed3-40f1-a092-d92463e4b87b), Stack size too large. Stack address: 0x7fb7fddf0000, frame address: 0x7fb7fe1ef100, stack size: 4198144, maximum stack size: 8388608 2025.07.28 11:52:56.903404 [ 17207 ] {c88d86d9-1bf7-43f8-8834-04c687184b57} PushingToViews: Failed to push block to view test_5.v1 (4ae2feef-b6fa-47ac-b20c-744da14b2a0a), Stack size too large. Stack address: 0x7fb7fddf0000, frame address: 0x7fb7fe1ef100, stack size: 4198144, maximum stack size: 8388608 2025.07.28 11:52:56.907804 [ 17207 ] {c88d86d9-1bf7-43f8-8834-04c687184b57} PushingToViews: Failed to push block to view test_5.v2 (7c22a887-3ed3-40f1-a092-d92463e4b87b), Stack size too large. Stack address: 0x7fb7fddf0000, frame address: 0x7fb7fe1ef100, stack size: 4198144, maximum stack size: 8388608 2025.07.28 11:52:56.913086 [ 17207 ] {c88d86d9-1bf7-43f8-8834-04c687184b57} PushingToViews: Failed to push block to view test_5.v1 (4ae2feef-b6fa-47ac-b20c-744da14b2a0a), Stack size too large. Stack address: 0x7fb7fddf0000, frame address: 0x7fb7fe1ef100, stack size: 4198144, maximum stack size: 8388608 2025.07.28 11:52:56.925037 [ 17207 ] {c88d86d9-1bf7-43f8-8834-04c687184b57} PushingToViews: Failed to push block to view test_5.v2 (7c22a887-3ed3-40f1-a092-d92463e4b87b), Stack size too large. Stack address: 0x7fb7fddf0000, frame address: 0x7fb7fe1ef100, stack size: 4198144, maximum stack size: 8388608 2025.07.28 11:52:56.926884 [ 17207 ] {c88d86d9-1bf7-43f8-8834-04c687184b57} PushingToViews: Failed to push block to view test_5.v1 (4ae2feef-b6fa-47ac-b20c-744da14b2a0a), Stack size too large. Stack address: 0x7fb7fddf0000, frame address: 0x7fb7fe1ef100, stack size: 4198144, maximum stack size: 8388608 2025.07.28 11:52:56.928823 [ 3961 ] {} test_13.rmt2 (7f9b740d-015c-470e-8cc6-8ba33be0dc63): auto DB::StorageReplicatedMergeTree::processQueueEntry(ReplicatedMergeTreeQueue::SelectedEntryPtr)::(anonymous class)::operator()(LogEntryPtr &) const: Code: 86. DB::HTTPException: Received error from remote server http://146b4357c08d:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Ftest%2F01165%2Ftest_13%2Frmt%2Freplicas%2F1&part=20250728_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.6.10636.altinitytest (altinity build)) '. (RECEIVED_ERROR_FROM_REMOTE_IO_SERVER), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.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 const&, int&&, String const&, unsigned long&&, String const&) @ 0x000000000feda8d9 4. /build/src/IO/HTTPCommon.cpp:104: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x000000000feda6e2 5. /build/src/IO/HTTPCommon.cpp:93: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x000000000feda537 6. /build/src/IO/ReadWriteBufferFromHTTP.cpp:277: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x000000001184a4c4 7. /build/src/IO/ReadWriteBufferFromHTTP.cpp:285: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x000000001184a615 8. /build/src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x000000001184ae59 9. /build/src/IO/ReadWriteBufferFromHTTP.cpp:472: void std::__function::__policy_invoker::__call_impl[abi:se190107]>(std::__function::__policy_storage const*) @ 0x000000001184cedd 10. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001184858b 11. /build/src/IO/ReadWriteBufferFromHTTP.cpp:465: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x000000001184bf0b 12. /build/src/IO/ReadBuffer.h:60: DB::ReadBuffer::next() @ 0x000000000a148c7b 13. /build/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) @ 0x0000000011849fb2 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]>&)>&, 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&) @ 0x0000000011841980 15. /build/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) @ 0x000000001621208e 16. /build/src/Storages/StorageReplicatedMergeTree.cpp:5228: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl[abi:se190107] const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000015f9a5fe 17. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000015ed8bfd 18. /build/src/Storages/StorageReplicatedMergeTree.cpp:2514: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x0000000015ec9aab 19. /build/src/Storages/StorageReplicatedMergeTree.cpp:2349: DB::StorageReplicatedMergeTree::executeLogEntry(DB::ReplicatedMergeTreeLogEntry&) @ 0x0000000015eba91b 20. /build/src/Storages/StorageReplicatedMergeTree.cpp:3876: bool std::__function::__policy_invoker&)>::__call_impl[abi:se190107])::$_1, bool (std::shared_ptr&)>>(std::__function::__policy_storage const*, std::shared_ptr&) @ 0x0000000015f9837e 21. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000165d6fc3 22. /build/src/Storages/StorageReplicatedMergeTree.cpp:3872: DB::StorageReplicatedMergeTree::processQueueEntry(std::shared_ptr) @ 0x0000000015efc18a 23. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001624c1b2 24. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000162f9c70 25. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x00000000162fa55a 26. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc6653 27. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000000fccc4c3 28. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc3d92 29. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fcca080 30. ? @ 0x00007fbc6213eac3 31. ? @ 0x00007fbc621d0850 (version 25.3.6.10636.altinitytest (altinity build)) 2025.07.28 11:52:56.929830 [ 17207 ] {c88d86d9-1bf7-43f8-8834-04c687184b57} PushingToViews: Failed to push block to view test_5.v2 (7c22a887-3ed3-40f1-a092-d92463e4b87b), Stack size too large. Stack address: 0x7fb7fddf0000, frame address: 0x7fb7fe1ef100, stack size: 4198144, maximum stack size: 8388608 2025.07.28 11:52:56.940812 [ 17207 ] {c88d86d9-1bf7-43f8-8834-04c687184b57} PushingToViews: Failed to push block to view test_5.v1 (4ae2feef-b6fa-47ac-b20c-744da14b2a0a), Stack size too large. Stack address: 0x7fb7fddf0000, frame address: 0x7fb7fe1ef100, stack size: 4198144, maximum stack size: 8388608 2025.07.28 11:52:56.954192 [ 17207 ] {c88d86d9-1bf7-43f8-8834-04c687184b57} PushingToViews: Failed to push block to view test_5.v2 (7c22a887-3ed3-40f1-a092-d92463e4b87b), Stack size too large. Stack address: 0x7fb7fddf0000, frame address: 0x7fb7fe1ef100, stack size: 4198144, maximum stack size: 8388608 2025.07.28 11:52:56.963963 [ 17207 ] {c88d86d9-1bf7-43f8-8834-04c687184b57} PushingToViews: Failed to push block to view test_5.v1 (4ae2feef-b6fa-47ac-b20c-744da14b2a0a), Stack size too large. Stack address: 0x7fb7fddf0000, frame address: 0x7fb7fe1ef100, stack size: 4198144, maximum stack size: 8388608 2025.07.28 11:52:56.972437 [ 17207 ] {c88d86d9-1bf7-43f8-8834-04c687184b57} PushingToViews: Failed to push block to view test_5.v2 (7c22a887-3ed3-40f1-a092-d92463e4b87b), Stack size too large. Stack address: 0x7fb7fddf0000, frame address: 0x7fb7fe1ef100, stack size: 4198144, maximum stack size: 8388608 2025.07.28 11:52:56.980663 [ 17207 ] {c88d86d9-1bf7-43f8-8834-04c687184b57} PushingToViews: Failed to push block to view test_5.v1 (4ae2feef-b6fa-47ac-b20c-744da14b2a0a), Stack size too large. Stack address: 0x7fb7fddf0000, frame address: 0x7fb7fe1ef100, stack size: 4198144, maximum stack size: 8388608 2025.07.28 11:52:56.990956 [ 17207 ] {c88d86d9-1bf7-43f8-8834-04c687184b57} PushingToViews: Failed to push block to view test_5.v2 (7c22a887-3ed3-40f1-a092-d92463e4b87b), Stack size too large. Stack address: 0x7fb7fddf0000, frame address: 0x7fb7fe1ef100, stack size: 4198144, maximum stack size: 8388608 2025.07.28 11:52:57.011714 [ 17207 ] {c88d86d9-1bf7-43f8-8834-04c687184b57} PushingToViews: Failed to push block to view test_5.v1 (4ae2feef-b6fa-47ac-b20c-744da14b2a0a), Stack size too large. Stack address: 0x7fb7fddf0000, frame address: 0x7fb7fe1ef100, stack size: 4198144, maximum stack size: 8388608 2025.07.28 11:52:57.014732 [ 17207 ] {c88d86d9-1bf7-43f8-8834-04c687184b57} PushingToViews: Failed to push block to view test_5.v2 (7c22a887-3ed3-40f1-a092-d92463e4b87b), Stack size too large. Stack address: 0x7fb7fddf0000, frame address: 0x7fb7fe1ef100, stack size: 4198144, maximum stack size: 8388608 2025.07.28 11:52:57.020210 [ 17207 ] {c88d86d9-1bf7-43f8-8834-04c687184b57} PushingToViews: Failed to push block to view test_5.v1 (4ae2feef-b6fa-47ac-b20c-744da14b2a0a), Stack size too large. Stack address: 0x7fb7fddf0000, frame address: 0x7fb7fe1ef100, stack size: 4198144, maximum stack size: 8388608 2025.07.28 11:52:57.031465 [ 17207 ] {c88d86d9-1bf7-43f8-8834-04c687184b57} PushingToViews: Failed to push block to view test_5.v2 (7c22a887-3ed3-40f1-a092-d92463e4b87b), Stack size too large. Stack address: 0x7fb7fddf0000, frame address: 0x7fb7fe1ef100, stack size: 4198144, maximum stack size: 8388608 2025.07.28 11:52:57.033054 [ 17207 ] {c88d86d9-1bf7-43f8-8834-04c687184b57} PushingToViews: Failed to push block to view test_5.v1 (4ae2feef-b6fa-47ac-b20c-744da14b2a0a), Stack size too large. Stack address: 0x7fb7fddf0000, frame address: 0x7fb7fe1ef100, stack size: 4198144, maximum stack size: 8388608 2025.07.28 11:52:57.034339 [ 17207 ] {c88d86d9-1bf7-43f8-8834-04c687184b57} PushingToViews: Failed to push block to view test_5.v2 (7c22a887-3ed3-40f1-a092-d92463e4b87b), Stack size too large. Stack address: 0x7fb7fddf0000, frame address: 0x7fb7fe1ef100, stack size: 4198144, maximum stack size: 8388608 2025.07.28 11:52:57.048426 [ 17207 ] {c88d86d9-1bf7-43f8-8834-04c687184b57} PushingToViews: Failed to push block to view test_5.v1 (4ae2feef-b6fa-47ac-b20c-744da14b2a0a), Stack size too large. Stack address: 0x7fb7fddf0000, frame address: 0x7fb7fe1ef100, stack size: 4198144, maximum stack size: 8388608 2025.07.28 11:52:57.049884 [ 17207 ] {c88d86d9-1bf7-43f8-8834-04c687184b57} PushingToViews: Failed to push block to view test_5.v2 (7c22a887-3ed3-40f1-a092-d92463e4b87b), Stack size too large. Stack address: 0x7fb7fddf0000, frame address: 0x7fb7fe1ef100, stack size: 4198144, maximum stack size: 8388608 2025.07.28 11:52:57.052119 [ 17207 ] {c88d86d9-1bf7-43f8-8834-04c687184b57} PushingToViews: Failed to push block to view test_5.v1 (4ae2feef-b6fa-47ac-b20c-744da14b2a0a), Stack size too large. Stack address: 0x7fb7fddf0000, frame address: 0x7fb7fe1ef100, stack size: 4198144, maximum stack size: 8388608 2025.07.28 11:52:57.054515 [ 17207 ] {c88d86d9-1bf7-43f8-8834-04c687184b57} PushingToViews: Failed to push block to view test_5.v2 (7c22a887-3ed3-40f1-a092-d92463e4b87b), Stack size too large. Stack address: 0x7fb7fddf0000, frame address: 0x7fb7fe1ef100, stack size: 4198144, maximum stack size: 8388608 2025.07.28 11:52:57.055862 [ 17207 ] {c88d86d9-1bf7-43f8-8834-04c687184b57} PushingToViews: Failed to push block to view test_5.v1 (4ae2feef-b6fa-47ac-b20c-744da14b2a0a), Stack size too large. Stack address: 0x7fb7fddf0000, frame address: 0x7fb7fe1ef100, stack size: 4198144, maximum stack size: 8388608 2025.07.28 11:52:57.057505 [ 17207 ] {c88d86d9-1bf7-43f8-8834-04c687184b57} PushingToViews: Failed to push block to view test_5.v2 (7c22a887-3ed3-40f1-a092-d92463e4b87b), Stack size too large. Stack address: 0x7fb7fddf0000, frame address: 0x7fb7fe1ef100, stack size: 4198144, maximum stack size: 8388608 2025.07.28 11:52:57.059806 [ 17207 ] {c88d86d9-1bf7-43f8-8834-04c687184b57} PushingToViews: Failed to push block to view test_5.v1 (4ae2feef-b6fa-47ac-b20c-744da14b2a0a), Stack size too large. Stack address: 0x7fb7fddf0000, frame address: 0x7fb7fe1ef100, stack size: 4198144, maximum stack size: 8388608 2025.07.28 11:52:57.061705 [ 17207 ] {c88d86d9-1bf7-43f8-8834-04c687184b57} PushingToViews: Failed to push block to view test_5.v2 (7c22a887-3ed3-40f1-a092-d92463e4b87b), Stack size too large. Stack address: 0x7fb7fddf0000, frame address: 0x7fb7fe1ef100, stack size: 4198144, maximum stack size: 8388608 2025.07.28 11:52:57.070783 [ 17207 ] {c88d86d9-1bf7-43f8-8834-04c687184b57} PushingToViews: Failed to push block to view test_5.v1 (4ae2feef-b6fa-47ac-b20c-744da14b2a0a), Stack size too large. Stack address: 0x7fb7fddf0000, frame address: 0x7fb7fe1ef100, stack size: 4198144, maximum stack size: 8388608 2025.07.28 11:52:57.072621 [ 17207 ] {c88d86d9-1bf7-43f8-8834-04c687184b57} PushingToViews: Failed to push block to view test_5.v2 (7c22a887-3ed3-40f1-a092-d92463e4b87b), Stack size too large. Stack address: 0x7fb7fddf0000, frame address: 0x7fb7fe1ef100, stack size: 4198144, maximum stack size: 8388608 2025.07.28 11:52:57.074605 [ 17207 ] {c88d86d9-1bf7-43f8-8834-04c687184b57} PushingToViews: Failed to push block to view test_5.v1 (4ae2feef-b6fa-47ac-b20c-744da14b2a0a), Stack size too large. Stack address: 0x7fb7fddf0000, frame address: 0x7fb7fe1ef100, stack size: 4198144, maximum stack size: 8388608 2025.07.28 11:52:57.075999 [ 17207 ] {c88d86d9-1bf7-43f8-8834-04c687184b57} PushingToViews: Failed to push block to view test_5.v2 (7c22a887-3ed3-40f1-a092-d92463e4b87b), Stack size too large. Stack address: 0x7fb7fddf0000, frame address: 0x7fb7fe1ef100, stack size: 4198144, maximum stack size: 8388608 2025.07.28 11:52:57.077154 [ 17207 ] {c88d86d9-1bf7-43f8-8834-04c687184b57} PushingToViews: Failed to push block to view test_5.v1 (4ae2feef-b6fa-47ac-b20c-744da14b2a0a), Stack size too large. Stack address: 0x7fb7fddf0000, frame address: 0x7fb7fe1ef100, stack size: 4198144, maximum stack size: 8388608 2025.07.28 11:52:57.078974 [ 17207 ] {c88d86d9-1bf7-43f8-8834-04c687184b57} PushingToViews: Failed to push block to view test_5.v2 (7c22a887-3ed3-40f1-a092-d92463e4b87b), Stack size too large. Stack address: 0x7fb7fddf0000, frame address: 0x7fb7fe1ef100, stack size: 4198144, maximum stack size: 8388608 2025.07.28 11:52:57.079996 [ 17207 ] {c88d86d9-1bf7-43f8-8834-04c687184b57} PushingToViews: Failed to push block to view test_5.v1 (4ae2feef-b6fa-47ac-b20c-744da14b2a0a), Stack size too large. Stack address: 0x7fb7fddf0000, frame address: 0x7fb7fe1ef100, stack size: 4198144, maximum stack size: 8388608 2025.07.28 11:52:57.081459 [ 17207 ] {c88d86d9-1bf7-43f8-8834-04c687184b57} PushingToViews: Failed to push block to view test_5.v2 (7c22a887-3ed3-40f1-a092-d92463e4b87b), Stack size too large. Stack address: 0x7fb7fddf0000, frame address: 0x7fb7fe1ef100, stack size: 4198144, maximum stack size: 8388608 2025.07.28 11:52:57.082767 [ 17207 ] {c88d86d9-1bf7-43f8-8834-04c687184b57} PushingToViews: Failed to push block to view test_5.v1 (4ae2feef-b6fa-47ac-b20c-744da14b2a0a), Stack size too large. Stack address: 0x7fb7fddf0000, frame address: 0x7fb7fe1ef100, stack size: 4198144, maximum stack size: 8388608 2025.07.28 11:52:57.084894 [ 17207 ] {c88d86d9-1bf7-43f8-8834-04c687184b57} PushingToViews: Failed to push block to view test_5.v2 (7c22a887-3ed3-40f1-a092-d92463e4b87b), Stack size too large. Stack address: 0x7fb7fddf0000, frame address: 0x7fb7fe1ef100, stack size: 4198144, maximum stack size: 8388608 2025.07.28 11:52:57.086334 [ 17207 ] {c88d86d9-1bf7-43f8-8834-04c687184b57} PushingToViews: Failed to push block to view test_5.v1 (4ae2feef-b6fa-47ac-b20c-744da14b2a0a), Stack size too large. Stack address: 0x7fb7fddf0000, frame address: 0x7fb7fe1ef100, stack size: 4198144, maximum stack size: 8388608 2025.07.28 11:52:57.089504 [ 17207 ] {c88d86d9-1bf7-43f8-8834-04c687184b57} PushingToViews: Failed to push block to view test_5.v2 (7c22a887-3ed3-40f1-a092-d92463e4b87b), Stack size too large. Stack address: 0x7fb7fddf0000, frame address: 0x7fb7fe1ef100, stack size: 4198144, maximum stack size: 8388608 2025.07.28 11:52:57.097095 [ 17207 ] {c88d86d9-1bf7-43f8-8834-04c687184b57} PushingToViews: Failed to push block to view test_5.v1 (4ae2feef-b6fa-47ac-b20c-744da14b2a0a), Stack size too large. Stack address: 0x7fb7fddf0000, frame address: 0x7fb7fe1ef100, stack size: 4198144, maximum stack size: 8388608 2025.07.28 11:52:57.102804 [ 17207 ] {c88d86d9-1bf7-43f8-8834-04c687184b57} PushingToViews: Failed to push block to view test_5.v2 (7c22a887-3ed3-40f1-a092-d92463e4b87b), Stack size too large. Stack address: 0x7fb7fddf0000, frame address: 0x7fb7fe1ef100, stack size: 4198144, maximum stack size: 8388608 2025.07.28 11:52:57.105046 [ 17207 ] {c88d86d9-1bf7-43f8-8834-04c687184b57} PushingToViews: Failed to push block to view test_5.v1 (4ae2feef-b6fa-47ac-b20c-744da14b2a0a), Stack size too large. Stack address: 0x7fb7fddf0000, frame address: 0x7fb7fe1ef100, stack size: 4198144, maximum stack size: 8388608 2025.07.28 11:52:57.106827 [ 17207 ] {c88d86d9-1bf7-43f8-8834-04c687184b57} PushingToViews: Failed to push block to view test_5.v2 (7c22a887-3ed3-40f1-a092-d92463e4b87b), Stack size too large. Stack address: 0x7fb7fddf0000, frame address: 0x7fb7fe1ef100, stack size: 4198144, maximum stack size: 8388608 2025.07.28 11:52:57.113149 [ 17207 ] {c88d86d9-1bf7-43f8-8834-04c687184b57} PushingToViews: Failed to push block to view test_5.v1 (4ae2feef-b6fa-47ac-b20c-744da14b2a0a), Stack size too large. Stack address: 0x7fb7fddf0000, frame address: 0x7fb7fe1ef100, stack size: 4198144, maximum stack size: 8388608 2025.07.28 11:52:57.119858 [ 17207 ] {c88d86d9-1bf7-43f8-8834-04c687184b57} PushingToViews: Failed to push block to view test_5.v2 (7c22a887-3ed3-40f1-a092-d92463e4b87b), Stack size too large. Stack address: 0x7fb7fddf0000, frame address: 0x7fb7fe1ef100, stack size: 4198144, maximum stack size: 8388608 2025.07.28 11:52:57.121185 [ 17207 ] {c88d86d9-1bf7-43f8-8834-04c687184b57} PushingToViews: Failed to push block to view test_5.v1 (4ae2feef-b6fa-47ac-b20c-744da14b2a0a), Stack size too large. Stack address: 0x7fb7fddf0000, frame address: 0x7fb7fe1ef100, stack size: 4198144, maximum stack size: 8388608 2025.07.28 11:52:57.122871 [ 17207 ] {c88d86d9-1bf7-43f8-8834-04c687184b57} PushingToViews: Failed to push block to view test_5.v2 (7c22a887-3ed3-40f1-a092-d92463e4b87b), Stack size too large. Stack address: 0x7fb7fddf0000, frame address: 0x7fb7fe1ef100, stack size: 4198144, maximum stack size: 8388608 2025.07.28 11:52:57.124664 [ 17207 ] {c88d86d9-1bf7-43f8-8834-04c687184b57} PushingToViews: Failed to push block to view test_5.v1 (4ae2feef-b6fa-47ac-b20c-744da14b2a0a), Stack size too large. Stack address: 0x7fb7fddf0000, frame address: 0x7fb7fe1ef100, stack size: 4198144, maximum stack size: 8388608 2025.07.28 11:52:57.127902 [ 17207 ] {c88d86d9-1bf7-43f8-8834-04c687184b57} PushingToViews: Failed to push block to view test_5.v2 (7c22a887-3ed3-40f1-a092-d92463e4b87b), Stack size too large. Stack address: 0x7fb7fddf0000, frame address: 0x7fb7fe1ef100, stack size: 4198144, maximum stack size: 8388608 2025.07.28 11:52:57.130822 [ 17207 ] {c88d86d9-1bf7-43f8-8834-04c687184b57} PushingToViews: Failed to push block to view test_5.v1 (4ae2feef-b6fa-47ac-b20c-744da14b2a0a), Stack size too large. Stack address: 0x7fb7fddf0000, frame address: 0x7fb7fe1ef100, stack size: 4198144, maximum stack size: 8388608 2025.07.28 11:52:57.132213 [ 17207 ] {c88d86d9-1bf7-43f8-8834-04c687184b57} PushingToViews: Failed to push block to view test_5.v2 (7c22a887-3ed3-40f1-a092-d92463e4b87b), Stack size too large. Stack address: 0x7fb7fddf0000, frame address: 0x7fb7fe1ef100, stack size: 4198144, maximum stack size: 8388608 2025.07.28 11:52:57.133353 [ 17207 ] {c88d86d9-1bf7-43f8-8834-04c687184b57} PushingToViews: Failed to push block to view test_5.v1 (4ae2feef-b6fa-47ac-b20c-744da14b2a0a), Stack size too large. Stack address: 0x7fb7fddf0000, frame address: 0x7fb7fe1ef100, stack size: 4198144, maximum stack size: 8388608 2025.07.28 11:52:57.147766 [ 17207 ] {c88d86d9-1bf7-43f8-8834-04c687184b57} PushingToViews: Failed to push block to view test_5.v2 (7c22a887-3ed3-40f1-a092-d92463e4b87b), Stack size too large. Stack address: 0x7fb7fddf0000, frame address: 0x7fb7fe1ef100, stack size: 4198144, maximum stack size: 8388608 2025.07.28 11:52:57.153793 [ 17207 ] {c88d86d9-1bf7-43f8-8834-04c687184b57} PushingToViews: Failed to push block to view test_5.v1 (4ae2feef-b6fa-47ac-b20c-744da14b2a0a), Stack size too large. Stack address: 0x7fb7fddf0000, frame address: 0x7fb7fe1ef100, stack size: 4198144, maximum stack size: 8388608 2025.07.28 11:52:57.156163 [ 17207 ] {c88d86d9-1bf7-43f8-8834-04c687184b57} PushingToViews: Failed to push block to view test_5.v2 (7c22a887-3ed3-40f1-a092-d92463e4b87b), Stack size too large. Stack address: 0x7fb7fddf0000, frame address: 0x7fb7fe1ef100, stack size: 4198144, maximum stack size: 8388608 2025.07.28 11:52:57.157307 [ 17207 ] {c88d86d9-1bf7-43f8-8834-04c687184b57} PushingToViews: Failed to push block to view test_5.v1 (4ae2feef-b6fa-47ac-b20c-744da14b2a0a), Stack size too large. Stack address: 0x7fb7fddf0000, frame address: 0x7fb7fe1ef100, stack size: 4198144, maximum stack size: 8388608 2025.07.28 11:52:57.174859 [ 17207 ] {c88d86d9-1bf7-43f8-8834-04c687184b57} PushingToViews: Failed to push block to view test_5.v2 (7c22a887-3ed3-40f1-a092-d92463e4b87b), Stack size too large. Stack address: 0x7fb7fddf0000, frame address: 0x7fb7fe1ef100, stack size: 4198144, maximum stack size: 8388608 2025.07.28 11:52:57.179646 [ 17207 ] {c88d86d9-1bf7-43f8-8834-04c687184b57} PushingToViews: Failed to push block to view test_5.v1 (4ae2feef-b6fa-47ac-b20c-744da14b2a0a), Stack size too large. Stack address: 0x7fb7fddf0000, frame address: 0x7fb7fe1ef100, stack size: 4198144, maximum stack size: 8388608 2025.07.28 11:52:57.189120 [ 17207 ] {c88d86d9-1bf7-43f8-8834-04c687184b57} PushingToViews: Failed to push block to view test_5.v2 (7c22a887-3ed3-40f1-a092-d92463e4b87b), Stack size too large. Stack address: 0x7fb7fddf0000, frame address: 0x7fb7fe1ef100, stack size: 4198144, maximum stack size: 8388608 2025.07.28 11:52:57.203330 [ 17207 ] {c88d86d9-1bf7-43f8-8834-04c687184b57} PushingToViews: Failed to push block to view test_5.v1 (4ae2feef-b6fa-47ac-b20c-744da14b2a0a), Stack size too large. Stack address: 0x7fb7fddf0000, frame address: 0x7fb7fe1ef100, stack size: 4198144, maximum stack size: 8388608 2025.07.28 11:52:57.214078 [ 17207 ] {c88d86d9-1bf7-43f8-8834-04c687184b57} PushingToViews: Failed to push block to view test_5.v2 (7c22a887-3ed3-40f1-a092-d92463e4b87b), Stack size too large. Stack address: 0x7fb7fddf0000, frame address: 0x7fb7fe1ef100, stack size: 4198144, maximum stack size: 8388608 2025.07.28 11:52:57.215052 [ 17207 ] {c88d86d9-1bf7-43f8-8834-04c687184b57} PushingToViews: Failed to push block to view test_5.v1 (4ae2feef-b6fa-47ac-b20c-744da14b2a0a), Stack size too large. Stack address: 0x7fb7fddf0000, frame address: 0x7fb7fe1ef100, stack size: 4198144, maximum stack size: 8388608 2025.07.28 11:52:57.217137 [ 17207 ] {c88d86d9-1bf7-43f8-8834-04c687184b57} PushingToViews: Failed to push block to view test_5.v2 (7c22a887-3ed3-40f1-a092-d92463e4b87b), Stack size too large. Stack address: 0x7fb7fddf0000, frame address: 0x7fb7fe1ef100, stack size: 4198144, maximum stack size: 8388608 2025.07.28 11:52:57.218667 [ 17207 ] {c88d86d9-1bf7-43f8-8834-04c687184b57} PushingToViews: Failed to push block to view test_5.v1 (4ae2feef-b6fa-47ac-b20c-744da14b2a0a), Stack size too large. Stack address: 0x7fb7fddf0000, frame address: 0x7fb7fe1ef100, stack size: 4198144, maximum stack size: 8388608 2025.07.28 11:52:57.219780 [ 17207 ] {c88d86d9-1bf7-43f8-8834-04c687184b57} PushingToViews: Failed to push block to view test_5.v2 (7c22a887-3ed3-40f1-a092-d92463e4b87b), Stack size too large. Stack address: 0x7fb7fddf0000, frame address: 0x7fb7fe1ef100, stack size: 4198144, maximum stack size: 8388608 2025.07.28 11:52:57.220829 [ 17207 ] {c88d86d9-1bf7-43f8-8834-04c687184b57} PushingToViews: Failed to push block to view test_5.v1 (4ae2feef-b6fa-47ac-b20c-744da14b2a0a), Stack size too large. Stack address: 0x7fb7fddf0000, frame address: 0x7fb7fe1ef100, stack size: 4198144, maximum stack size: 8388608 2025.07.28 11:52:57.222335 [ 17207 ] {c88d86d9-1bf7-43f8-8834-04c687184b57} PushingToViews: Failed to push block to view test_5.v2 (7c22a887-3ed3-40f1-a092-d92463e4b87b), Stack size too large. Stack address: 0x7fb7fddf0000, frame address: 0x7fb7fe1ef100, stack size: 4198144, maximum stack size: 8388608 2025.07.28 11:52:57.223840 [ 17207 ] {c88d86d9-1bf7-43f8-8834-04c687184b57} PushingToViews: Failed to push block to view test_5.v1 (4ae2feef-b6fa-47ac-b20c-744da14b2a0a), Stack size too large. Stack address: 0x7fb7fddf0000, frame address: 0x7fb7fe1ef100, stack size: 4198144, maximum stack size: 8388608 2025.07.28 11:52:57.231551 [ 17207 ] {c88d86d9-1bf7-43f8-8834-04c687184b57} PushingToViews: Failed to push block to view test_5.v2 (7c22a887-3ed3-40f1-a092-d92463e4b87b), Stack size too large. Stack address: 0x7fb7fddf0000, frame address: 0x7fb7fe1ef100, stack size: 4198144, maximum stack size: 8388608 2025.07.28 11:52:57.275090 [ 17207 ] {c88d86d9-1bf7-43f8-8834-04c687184b57} PushingToViews: Failed to push block to view test_5.v1 (4ae2feef-b6fa-47ac-b20c-744da14b2a0a), Stack size too large. Stack address: 0x7fb7fddf0000, frame address: 0x7fb7fe1ef100, stack size: 4198144, maximum stack size: 8388608 2025.07.28 11:52:57.276811 [ 17207 ] {c88d86d9-1bf7-43f8-8834-04c687184b57} PushingToViews: Failed to push block to view test_5.v2 (7c22a887-3ed3-40f1-a092-d92463e4b87b), Stack size too large. Stack address: 0x7fb7fddf0000, frame address: 0x7fb7fe1ef100, stack size: 4198144, maximum stack size: 8388608 2025.07.28 11:52:57.278082 [ 17207 ] {c88d86d9-1bf7-43f8-8834-04c687184b57} PushingToViews: Failed to push block to view test_5.v1 (4ae2feef-b6fa-47ac-b20c-744da14b2a0a), Stack size too large. Stack address: 0x7fb7fddf0000, frame address: 0x7fb7fe1ef100, stack size: 4198144, maximum stack size: 8388608 2025.07.28 11:52:57.281607 [ 17207 ] {c88d86d9-1bf7-43f8-8834-04c687184b57} PushingToViews: Failed to push block to view test_5.v2 (7c22a887-3ed3-40f1-a092-d92463e4b87b), Stack size too large. Stack address: 0x7fb7fddf0000, frame address: 0x7fb7fe1ef100, stack size: 4198144, maximum stack size: 8388608 2025.07.28 11:52:57.282915 [ 17207 ] {c88d86d9-1bf7-43f8-8834-04c687184b57} PushingToViews: Failed to push block to view test_5.v1 (4ae2feef-b6fa-47ac-b20c-744da14b2a0a), Stack size too large. Stack address: 0x7fb7fddf0000, frame address: 0x7fb7fe1ef100, stack size: 4198144, maximum stack size: 8388608 2025.07.28 11:52:57.284257 [ 17207 ] {c88d86d9-1bf7-43f8-8834-04c687184b57} PushingToViews: Failed to push block to view test_5.v2 (7c22a887-3ed3-40f1-a092-d92463e4b87b), Stack size too large. Stack address: 0x7fb7fddf0000, frame address: 0x7fb7fe1ef100, stack size: 4198144, maximum stack size: 8388608 2025.07.28 11:52:57.286003 [ 17207 ] {c88d86d9-1bf7-43f8-8834-04c687184b57} PushingToViews: Failed to push block to view test_5.v1 (4ae2feef-b6fa-47ac-b20c-744da14b2a0a), Stack size too large. Stack address: 0x7fb7fddf0000, frame address: 0x7fb7fe1ef100, stack size: 4198144, maximum stack size: 8388608 2025.07.28 11:52:57.287230 [ 17207 ] {c88d86d9-1bf7-43f8-8834-04c687184b57} PushingToViews: Failed to push block to view test_5.v2 (7c22a887-3ed3-40f1-a092-d92463e4b87b), Stack size too large. Stack address: 0x7fb7fddf0000, frame address: 0x7fb7fe1ef100, stack size: 4198144, maximum stack size: 8388608 2025.07.28 11:52:57.288576 [ 17207 ] {c88d86d9-1bf7-43f8-8834-04c687184b57} PushingToViews: Failed to push block to view test_5.v1 (4ae2feef-b6fa-47ac-b20c-744da14b2a0a), Stack size too large. Stack address: 0x7fb7fddf0000, frame address: 0x7fb7fe1ef100, stack size: 4198144, maximum stack size: 8388608 2025.07.28 11:52:57.297835 [ 17207 ] {c88d86d9-1bf7-43f8-8834-04c687184b57} PushingToViews: Failed to push block to view test_5.v2 (7c22a887-3ed3-40f1-a092-d92463e4b87b), Stack size too large. Stack address: 0x7fb7fddf0000, frame address: 0x7fb7fe1ef100, stack size: 4198144, maximum stack size: 8388608 2025.07.28 11:52:57.298858 [ 17207 ] {c88d86d9-1bf7-43f8-8834-04c687184b57} PushingToViews: Failed to push block to view test_5.v1 (4ae2feef-b6fa-47ac-b20c-744da14b2a0a), Stack size too large. Stack address: 0x7fb7fddf0000, frame address: 0x7fb7fe1ef100, stack size: 4198144, maximum stack size: 8388608 2025.07.28 11:52:57.299871 [ 17207 ] {c88d86d9-1bf7-43f8-8834-04c687184b57} PushingToViews: Failed to push block to view test_5.v2 (7c22a887-3ed3-40f1-a092-d92463e4b87b), Stack size too large. Stack address: 0x7fb7fddf0000, frame address: 0x7fb7fe1ef100, stack size: 4198144, maximum stack size: 8388608 2025.07.28 11:52:57.300984 [ 17207 ] {c88d86d9-1bf7-43f8-8834-04c687184b57} PushingToViews: Failed to push block to view test_5.v1 (4ae2feef-b6fa-47ac-b20c-744da14b2a0a), Stack size too large. Stack address: 0x7fb7fddf0000, frame address: 0x7fb7fe1ef100, stack size: 4198144, maximum stack size: 8388608 2025.07.28 11:52:57.302881 [ 17207 ] {c88d86d9-1bf7-43f8-8834-04c687184b57} PushingToViews: Failed to push block to view test_5.v2 (7c22a887-3ed3-40f1-a092-d92463e4b87b), Stack size too large. Stack address: 0x7fb7fddf0000, frame address: 0x7fb7fe1ef100, stack size: 4198144, maximum stack size: 8388608 2025.07.28 11:52:57.304552 [ 17207 ] {c88d86d9-1bf7-43f8-8834-04c687184b57} PushingToViews: Failed to push block to view test_5.v1 (4ae2feef-b6fa-47ac-b20c-744da14b2a0a), Stack size too large. Stack address: 0x7fb7fddf0000, frame address: 0x7fb7fe1ef100, stack size: 4198144, maximum stack size: 8388608 2025.07.28 11:52:57.323275 [ 17207 ] {c88d86d9-1bf7-43f8-8834-04c687184b57} PushingToViews: Failed to push block to view test_5.v2 (7c22a887-3ed3-40f1-a092-d92463e4b87b), Stack size too large. Stack address: 0x7fb7fddf0000, frame address: 0x7fb7fe1ef100, stack size: 4198144, maximum stack size: 8388608 2025.07.28 11:52:57.325108 [ 17207 ] {c88d86d9-1bf7-43f8-8834-04c687184b57} PushingToViews: Failed to push block to view test_5.v1 (4ae2feef-b6fa-47ac-b20c-744da14b2a0a), Stack size too large. Stack address: 0x7fb7fddf0000, frame address: 0x7fb7fe1ef100, stack size: 4198144, maximum stack size: 8388608 2025.07.28 11:52:57.326492 [ 17207 ] {c88d86d9-1bf7-43f8-8834-04c687184b57} PushingToViews: Failed to push block to view test_5.v2 (7c22a887-3ed3-40f1-a092-d92463e4b87b), Stack size too large. Stack address: 0x7fb7fddf0000, frame address: 0x7fb7fe1ef100, stack size: 4198144, maximum stack size: 8388608 2025.07.28 11:52:57.327899 [ 17207 ] {c88d86d9-1bf7-43f8-8834-04c687184b57} PushingToViews: Failed to push block to view test_5.v1 (4ae2feef-b6fa-47ac-b20c-744da14b2a0a), Stack size too large. Stack address: 0x7fb7fddf0000, frame address: 0x7fb7fe1ef100, stack size: 4198144, maximum stack size: 8388608 2025.07.28 11:52:57.329988 [ 17207 ] {c88d86d9-1bf7-43f8-8834-04c687184b57} PushingToViews: Failed to push block to view test_5.v2 (7c22a887-3ed3-40f1-a092-d92463e4b87b), Stack size too large. Stack address: 0x7fb7fddf0000, frame address: 0x7fb7fe1ef100, stack size: 4198144, maximum stack size: 8388608 2025.07.28 11:52:57.331371 [ 17207 ] {c88d86d9-1bf7-43f8-8834-04c687184b57} PushingToViews: Failed to push block to view test_5.v1 (4ae2feef-b6fa-47ac-b20c-744da14b2a0a), Stack size too large. Stack address: 0x7fb7fddf0000, frame address: 0x7fb7fe1ef100, stack size: 4198144, maximum stack size: 8388608 2025.07.28 11:52:57.332580 [ 17207 ] {c88d86d9-1bf7-43f8-8834-04c687184b57} PushingToViews: Failed to push block to view test_5.v2 (7c22a887-3ed3-40f1-a092-d92463e4b87b), Stack size too large. Stack address: 0x7fb7fddf0000, frame address: 0x7fb7fe1ef100, stack size: 4198144, maximum stack size: 8388608 2025.07.28 11:52:57.333548 [ 17207 ] {c88d86d9-1bf7-43f8-8834-04c687184b57} PushingToViews: Failed to push block to view test_5.v1 (4ae2feef-b6fa-47ac-b20c-744da14b2a0a), Stack size too large. Stack address: 0x7fb7fddf0000, frame address: 0x7fb7fe1ef100, stack size: 4198144, maximum stack size: 8388608 2025.07.28 11:52:57.335207 [ 17207 ] {c88d86d9-1bf7-43f8-8834-04c687184b57} PushingToViews: Failed to push block to view test_5.v2 (7c22a887-3ed3-40f1-a092-d92463e4b87b), Stack size too large. Stack address: 0x7fb7fddf0000, frame address: 0x7fb7fe1ef100, stack size: 4198144, maximum stack size: 8388608 2025.07.28 11:52:57.336316 [ 17207 ] {c88d86d9-1bf7-43f8-8834-04c687184b57} PushingToViews: Failed to push block to view test_5.v1 (4ae2feef-b6fa-47ac-b20c-744da14b2a0a), Stack size too large. Stack address: 0x7fb7fddf0000, frame address: 0x7fb7fe1ef100, stack size: 4198144, maximum stack size: 8388608 2025.07.28 11:52:57.337208 [ 17207 ] {c88d86d9-1bf7-43f8-8834-04c687184b57} PushingToViews: Failed to push block to view test_5.v2 (7c22a887-3ed3-40f1-a092-d92463e4b87b), Stack size too large. Stack address: 0x7fb7fddf0000, frame address: 0x7fb7fe1ef100, stack size: 4198144, maximum stack size: 8388608 2025.07.28 11:52:57.345333 [ 17207 ] {c88d86d9-1bf7-43f8-8834-04c687184b57} PushingToViews: Failed to push block to view test_5.v1 (4ae2feef-b6fa-47ac-b20c-744da14b2a0a), Stack size too large. Stack address: 0x7fb7fddf0000, frame address: 0x7fb7fe1ef100, stack size: 4198144, maximum stack size: 8388608 2025.07.28 11:52:57.365342 [ 17207 ] {c88d86d9-1bf7-43f8-8834-04c687184b57} PushingToViews: Failed to push block to view test_5.v2 (7c22a887-3ed3-40f1-a092-d92463e4b87b), Stack size too large. Stack address: 0x7fb7fddf0000, frame address: 0x7fb7fe1ef100, stack size: 4198144, maximum stack size: 8388608 2025.07.28 11:52:57.367231 [ 17207 ] {c88d86d9-1bf7-43f8-8834-04c687184b57} PushingToViews: Failed to push block to view test_5.v1 (4ae2feef-b6fa-47ac-b20c-744da14b2a0a), Stack size too large. Stack address: 0x7fb7fddf0000, frame address: 0x7fb7fe1ef100, stack size: 4198144, maximum stack size: 8388608 2025.07.28 11:52:57.370175 [ 17207 ] {c88d86d9-1bf7-43f8-8834-04c687184b57} PushingToViews: Failed to push block to view test_5.v2 (7c22a887-3ed3-40f1-a092-d92463e4b87b), Stack size too large. Stack address: 0x7fb7fddf0000, frame address: 0x7fb7fe1ef100, stack size: 4198144, maximum stack size: 8388608 2025.07.28 11:52:57.371313 [ 17207 ] {c88d86d9-1bf7-43f8-8834-04c687184b57} PushingToViews: Failed to push block to view test_5.v1 (4ae2feef-b6fa-47ac-b20c-744da14b2a0a), Stack size too large. Stack address: 0x7fb7fddf0000, frame address: 0x7fb7fe1ef100, stack size: 4198144, maximum stack size: 8388608 2025.07.28 11:52:57.373111 [ 17207 ] {c88d86d9-1bf7-43f8-8834-04c687184b57} PushingToViews: Failed to push block to view test_5.v2 (7c22a887-3ed3-40f1-a092-d92463e4b87b), Stack size too large. Stack address: 0x7fb7fddf0000, frame address: 0x7fb7fe1ef100, stack size: 4198144, maximum stack size: 8388608 2025.07.28 11:52:57.374802 [ 17207 ] {c88d86d9-1bf7-43f8-8834-04c687184b57} PushingToViews: Failed to push block to view test_5.v1 (4ae2feef-b6fa-47ac-b20c-744da14b2a0a), Stack size too large. Stack address: 0x7fb7fddf0000, frame address: 0x7fb7fe1ef100, stack size: 4198144, maximum stack size: 8388608 2025.07.28 11:52:57.377199 [ 17207 ] {c88d86d9-1bf7-43f8-8834-04c687184b57} PushingToViews: Failed to push block to view test_5.v2 (7c22a887-3ed3-40f1-a092-d92463e4b87b), Stack size too large. Stack address: 0x7fb7fddf0000, frame address: 0x7fb7fe1ef100, stack size: 4198144, maximum stack size: 8388608 2025.07.28 11:52:57.382426 [ 17207 ] {c88d86d9-1bf7-43f8-8834-04c687184b57} PushingToViews: Failed to push block to view test_5.v1 (4ae2feef-b6fa-47ac-b20c-744da14b2a0a), Stack size too large. Stack address: 0x7fb7fddf0000, frame address: 0x7fb7fe1ef100, stack size: 4198144, maximum stack size: 8388608 2025.07.28 11:52:57.383361 [ 17207 ] {c88d86d9-1bf7-43f8-8834-04c687184b57} PushingToViews: Failed to push block to view test_5.v2 (7c22a887-3ed3-40f1-a092-d92463e4b87b), Stack size too large. Stack address: 0x7fb7fddf0000, frame address: 0x7fb7fe1ef100, stack size: 4198144, maximum stack size: 8388608 2025.07.28 11:52:57.385658 [ 17207 ] {c88d86d9-1bf7-43f8-8834-04c687184b57} PushingToViews: Failed to push block to view test_5.v1 (4ae2feef-b6fa-47ac-b20c-744da14b2a0a), Stack size too large. Stack address: 0x7fb7fddf0000, frame address: 0x7fb7fe1ef100, stack size: 4198144, maximum stack size: 8388608 2025.07.28 11:52:57.387113 [ 17207 ] {c88d86d9-1bf7-43f8-8834-04c687184b57} PushingToViews: Failed to push block to view test_5.v2 (7c22a887-3ed3-40f1-a092-d92463e4b87b), Stack size too large. Stack address: 0x7fb7fddf0000, frame address: 0x7fb7fe1ef100, stack size: 4198144, maximum stack size: 8388608 2025.07.28 11:52:57.388156 [ 17207 ] {c88d86d9-1bf7-43f8-8834-04c687184b57} PushingToViews: Failed to push block to view test_5.v1 (4ae2feef-b6fa-47ac-b20c-744da14b2a0a), Stack size too large. Stack address: 0x7fb7fddf0000, frame address: 0x7fb7fe1ef100, stack size: 4198144, maximum stack size: 8388608 2025.07.28 11:52:57.390314 [ 17207 ] {c88d86d9-1bf7-43f8-8834-04c687184b57} PushingToViews: Failed to push block to view test_5.v2 (7c22a887-3ed3-40f1-a092-d92463e4b87b), Stack size too large. Stack address: 0x7fb7fddf0000, frame address: 0x7fb7fe1ef100, stack size: 4198144, maximum stack size: 8388608 2025.07.28 11:52:57.391447 [ 17207 ] {c88d86d9-1bf7-43f8-8834-04c687184b57} PushingToViews: Failed to push block to view test_5.v1 (4ae2feef-b6fa-47ac-b20c-744da14b2a0a), Stack size too large. Stack address: 0x7fb7fddf0000, frame address: 0x7fb7fe1ef100, stack size: 4198144, maximum stack size: 8388608 2025.07.28 11:52:57.392824 [ 17207 ] {c88d86d9-1bf7-43f8-8834-04c687184b57} PushingToViews: Failed to push block to view test_5.v2 (7c22a887-3ed3-40f1-a092-d92463e4b87b), Stack size too large. Stack address: 0x7fb7fddf0000, frame address: 0x7fb7fe1ef100, stack size: 4198144, maximum stack size: 8388608 2025.07.28 11:52:57.394027 [ 17207 ] {c88d86d9-1bf7-43f8-8834-04c687184b57} PushingToViews: Failed to push block to view test_5.v1 (4ae2feef-b6fa-47ac-b20c-744da14b2a0a), Stack size too large. Stack address: 0x7fb7fddf0000, frame address: 0x7fb7fe1ef100, stack size: 4198144, maximum stack size: 8388608 2025.07.28 11:52:57.395145 [ 17207 ] {c88d86d9-1bf7-43f8-8834-04c687184b57} PushingToViews: Failed to push block to view test_5.v2 (7c22a887-3ed3-40f1-a092-d92463e4b87b), Stack size too large. Stack address: 0x7fb7fddf0000, frame address: 0x7fb7fe1ef100, stack size: 4198144, maximum stack size: 8388608 2025.07.28 11:52:57.397426 [ 17207 ] {c88d86d9-1bf7-43f8-8834-04c687184b57} PushingToViews: Failed to push block to view test_5.v1 (4ae2feef-b6fa-47ac-b20c-744da14b2a0a), Stack size too large. Stack address: 0x7fb7fddf0000, frame address: 0x7fb7fe1ef100, stack size: 4198144, maximum stack size: 8388608 2025.07.28 11:52:57.398270 [ 17207 ] {c88d86d9-1bf7-43f8-8834-04c687184b57} PushingToViews: Failed to push block to view test_5.v2 (7c22a887-3ed3-40f1-a092-d92463e4b87b), Stack size too large. Stack address: 0x7fb7fddf0000, frame address: 0x7fb7fe1ef100, stack size: 4198144, maximum stack size: 8388608 2025.07.28 11:52:57.399503 [ 17207 ] {c88d86d9-1bf7-43f8-8834-04c687184b57} PushingToViews: Failed to push block to view test_5.v1 (4ae2feef-b6fa-47ac-b20c-744da14b2a0a), Stack size too large. Stack address: 0x7fb7fddf0000, frame address: 0x7fb7fe1ef100, stack size: 4198144, maximum stack size: 8388608 2025.07.28 11:52:57.401315 [ 17207 ] {c88d86d9-1bf7-43f8-8834-04c687184b57} PushingToViews: Failed to push block to view test_5.v2 (7c22a887-3ed3-40f1-a092-d92463e4b87b), Stack size too large. Stack address: 0x7fb7fddf0000, frame address: 0x7fb7fe1ef100, stack size: 4198144, maximum stack size: 8388608 2025.07.28 11:52:57.402408 [ 17207 ] {c88d86d9-1bf7-43f8-8834-04c687184b57} PushingToViews: Failed to push block to view test_5.v1 (4ae2feef-b6fa-47ac-b20c-744da14b2a0a), Stack size too large. Stack address: 0x7fb7fddf0000, frame address: 0x7fb7fe1ef100, stack size: 4198144, maximum stack size: 8388608 2025.07.28 11:52:57.403879 [ 17207 ] {c88d86d9-1bf7-43f8-8834-04c687184b57} PushingToViews: Failed to push block to view test_5.v2 (7c22a887-3ed3-40f1-a092-d92463e4b87b), Stack size too large. Stack address: 0x7fb7fddf0000, frame address: 0x7fb7fe1ef100, stack size: 4198144, maximum stack size: 8388608 2025.07.28 11:52:57.405706 [ 17207 ] {c88d86d9-1bf7-43f8-8834-04c687184b57} PushingToViews: Failed to push block to view test_5.v1 (4ae2feef-b6fa-47ac-b20c-744da14b2a0a), Stack size too large. Stack address: 0x7fb7fddf0000, frame address: 0x7fb7fe1ef100, stack size: 4198144, maximum stack size: 8388608 2025.07.28 11:52:57.407309 [ 17611 ] {ef52cdb4-c8f5-4a27-b0cb-04038a00e355} executeQuery: Code: 47. DB::Exception: Unknown expression or function identifier `x` in scope x = 1. (UNKNOWN_IDENTIFIER) (version 25.3.6.10636.altinitytest (altinity build)) (from [::1]:47460) (comment: 02000_map_full_text_bloom_filter_index.sql) (query 7, line 18) (in query: SELECT * FROM bf_tokenbf_map_keys_test WHERE map['K0'] = 'V0' SETTINGS force_data_skipping_indices='map_keys_tokenbf';), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.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&&) @ 0x000000001404b3b9 4. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3771: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000001401b849 5. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3980: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000014018e31 6. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:2925: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000001402fcbd 7. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3838: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000014019a9e 8. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:209: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000001401270e 9. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000014011fce 10. /build/src/Planner/Utils.cpp:458: DB::buildFilterInfo(std::shared_ptr, std::shared_ptr const&, std::shared_ptr&, std::unordered_set, std::equal_to, std::allocator>) @ 0x0000000013fe8bcf 11. /build/src/Planner/PlannerJoinTree.cpp:535: DB::(anonymous namespace)::buildQueryPlanForTableExpression(std::shared_ptr, std::shared_ptr const&, DB::SelectQueryInfo const&, DB::SelectQueryOptions const&, std::shared_ptr&, bool, bool) @ 0x00000000149956d3 12. /build/src/Planner/PlannerJoinTree.cpp:2252: DB::buildJoinTreeQueryPlan(std::shared_ptr const&, DB::SelectQueryInfo const&, DB::SelectQueryOptions&, std::unordered_set, std::equal_to, std::allocator> const&, std::shared_ptr&) @ 0x000000001498e109 13. /build/src/Planner/Planner.cpp:1553: DB::Planner::buildPlanForQueryNode() @ 0x0000000014979dae 14. /build/src/Planner/Planner.cpp:1308: DB::Planner::buildQueryPlanIfNeeded() @ 0x000000001497685c 15. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:255: DB::InterpreterSelectQueryAnalyzer::getQueryPlan() @ 0x000000001497476d 16. /build/src/Interpreters/executeQuery.cpp:1405: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88806 17. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 18. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 19. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 20. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 21. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 22. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 23. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 24. ? @ 0x00007fbc6213eac3 25. ? @ 0x00007fbc621d0850 2025.07.28 11:52:57.407722 [ 17207 ] {c88d86d9-1bf7-43f8-8834-04c687184b57} PushingToViews: Failed to push block to view test_5.v2 (7c22a887-3ed3-40f1-a092-d92463e4b87b), Stack size too large. Stack address: 0x7fb7fddf0000, frame address: 0x7fb7fe1ef100, stack size: 4198144, maximum stack size: 8388608 2025.07.28 11:52:57.409372 [ 17207 ] {c88d86d9-1bf7-43f8-8834-04c687184b57} PushingToViews: Failed to push block to view test_5.v1 (4ae2feef-b6fa-47ac-b20c-744da14b2a0a), Stack size too large. Stack address: 0x7fb7fddf0000, frame address: 0x7fb7fe1ef100, stack size: 4198144, maximum stack size: 8388608 2025.07.28 11:52:57.410713 [ 17207 ] {c88d86d9-1bf7-43f8-8834-04c687184b57} PushingToViews: Failed to push block to view test_5.v2 (7c22a887-3ed3-40f1-a092-d92463e4b87b), Stack size too large. Stack address: 0x7fb7fddf0000, frame address: 0x7fb7fe1ef100, stack size: 4198144, maximum stack size: 8388608 2025.07.28 11:52:57.418220 [ 17611 ] {} TCPHandler: Code: 47. DB::Exception: Unknown expression or function identifier `x` in scope x = 1. (UNKNOWN_IDENTIFIER), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.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&&) @ 0x000000001404b3b9 4. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3771: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000001401b849 5. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3980: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000014018e31 6. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:2925: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000001402fcbd 7. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3838: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000014019a9e 8. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:209: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000001401270e 9. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000014011fce 10. /build/src/Planner/Utils.cpp:458: DB::buildFilterInfo(std::shared_ptr, std::shared_ptr const&, std::shared_ptr&, std::unordered_set, std::equal_to, std::allocator>) @ 0x0000000013fe8bcf 11. /build/src/Planner/PlannerJoinTree.cpp:535: DB::(anonymous namespace)::buildQueryPlanForTableExpression(std::shared_ptr, std::shared_ptr const&, DB::SelectQueryInfo const&, DB::SelectQueryOptions const&, std::shared_ptr&, bool, bool) @ 0x00000000149956d3 12. /build/src/Planner/PlannerJoinTree.cpp:2252: DB::buildJoinTreeQueryPlan(std::shared_ptr const&, DB::SelectQueryInfo const&, DB::SelectQueryOptions&, std::unordered_set, std::equal_to, std::allocator> const&, std::shared_ptr&) @ 0x000000001498e109 13. /build/src/Planner/Planner.cpp:1553: DB::Planner::buildPlanForQueryNode() @ 0x0000000014979dae 14. /build/src/Planner/Planner.cpp:1308: DB::Planner::buildQueryPlanIfNeeded() @ 0x000000001497685c 15. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:255: DB::InterpreterSelectQueryAnalyzer::getQueryPlan() @ 0x000000001497476d 16. /build/src/Interpreters/executeQuery.cpp:1405: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88806 17. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 18. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 19. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 20. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 21. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 22. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 23. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 24. ? @ 0x00007fbc6213eac3 25. ? @ 0x00007fbc621d0850 2025.07.28 11:52:57.423187 [ 17207 ] {c88d86d9-1bf7-43f8-8834-04c687184b57} PushingToViews: Failed to push block to view test_5.v1 (4ae2feef-b6fa-47ac-b20c-744da14b2a0a), Stack size too large. Stack address: 0x7fb7fddf0000, frame address: 0x7fb7fe1ef100, stack size: 4198144, maximum stack size: 8388608 2025.07.28 11:52:57.426547 [ 17207 ] {c88d86d9-1bf7-43f8-8834-04c687184b57} PushingToViews: Failed to push block to view test_5.v2 (7c22a887-3ed3-40f1-a092-d92463e4b87b), Stack size too large. Stack address: 0x7fb7fddf0000, frame address: 0x7fb7fe1ef100, stack size: 4198144, maximum stack size: 8388608 2025.07.28 11:52:57.438604 [ 17207 ] {c88d86d9-1bf7-43f8-8834-04c687184b57} PushingToViews: Failed to push block to view test_5.v1 (4ae2feef-b6fa-47ac-b20c-744da14b2a0a), Stack size too large. Stack address: 0x7fb7fddf0000, frame address: 0x7fb7fe1ef100, stack size: 4198144, maximum stack size: 8388608 2025.07.28 11:52:57.441524 [ 17207 ] {c88d86d9-1bf7-43f8-8834-04c687184b57} PushingToViews: Failed to push block to view test_5.v2 (7c22a887-3ed3-40f1-a092-d92463e4b87b), Stack size too large. Stack address: 0x7fb7fddf0000, frame address: 0x7fb7fe1ef100, stack size: 4198144, maximum stack size: 8388608 2025.07.28 11:52:57.442873 [ 17207 ] {c88d86d9-1bf7-43f8-8834-04c687184b57} PushingToViews: Failed to push block to view test_5.v1 (4ae2feef-b6fa-47ac-b20c-744da14b2a0a), Stack size too large. Stack address: 0x7fb7fddf0000, frame address: 0x7fb7fe1ef100, stack size: 4198144, maximum stack size: 8388608 2025.07.28 11:52:57.447464 [ 17207 ] {c88d86d9-1bf7-43f8-8834-04c687184b57} PushingToViews: Failed to push block to view test_5.v2 (7c22a887-3ed3-40f1-a092-d92463e4b87b), Stack size too large. Stack address: 0x7fb7fddf0000, frame address: 0x7fb7fe1ef100, stack size: 4198144, maximum stack size: 8388608 2025.07.28 11:52:57.459282 [ 17207 ] {c88d86d9-1bf7-43f8-8834-04c687184b57} PushingToViews: Failed to push block to view test_5.v1 (4ae2feef-b6fa-47ac-b20c-744da14b2a0a), Stack size too large. Stack address: 0x7fb7fddf0000, frame address: 0x7fb7fe1ef100, stack size: 4198144, maximum stack size: 8388608 2025.07.28 11:52:57.464390 [ 17207 ] {c88d86d9-1bf7-43f8-8834-04c687184b57} PushingToViews: Failed to push block to view test_5.v2 (7c22a887-3ed3-40f1-a092-d92463e4b87b), Stack size too large. Stack address: 0x7fb7fddf0000, frame address: 0x7fb7fe1ef100, stack size: 4198144, maximum stack size: 8388608 2025.07.28 11:52:57.471694 [ 17207 ] {c88d86d9-1bf7-43f8-8834-04c687184b57} PushingToViews: Failed to push block to view test_5.v1 (4ae2feef-b6fa-47ac-b20c-744da14b2a0a), Stack size too large. Stack address: 0x7fb7fddf0000, frame address: 0x7fb7fe1ef100, stack size: 4198144, maximum stack size: 8388608 2025.07.28 11:52:57.483470 [ 17207 ] {c88d86d9-1bf7-43f8-8834-04c687184b57} PushingToViews: Failed to push block to view test_5.v2 (7c22a887-3ed3-40f1-a092-d92463e4b87b), Stack size too large. Stack address: 0x7fb7fddf0000, frame address: 0x7fb7fe1ef100, stack size: 4198144, maximum stack size: 8388608 2025.07.28 11:52:57.514030 [ 17207 ] {c88d86d9-1bf7-43f8-8834-04c687184b57} PushingToViews: Failed to push block to view test_5.v1 (4ae2feef-b6fa-47ac-b20c-744da14b2a0a), Stack size too large. Stack address: 0x7fb7fddf0000, frame address: 0x7fb7fe1ef100, stack size: 4198144, maximum stack size: 8388608 2025.07.28 11:52:57.514922 [ 17207 ] {c88d86d9-1bf7-43f8-8834-04c687184b57} PushingToViews: Failed to push block to view test_5.v2 (7c22a887-3ed3-40f1-a092-d92463e4b87b), Stack size too large. Stack address: 0x7fb7fddf0000, frame address: 0x7fb7fe1ef100, stack size: 4198144, maximum stack size: 8388608 2025.07.28 11:52:57.520010 [ 7416 ] {794d2e6f-306e-4835-ad31-6d66aeb0a9e0} ExternalDictionariesLoader: Could not load external dictionary 'cc8b1a52-da70-449c-9c23-8d623c5fcc44', next update is scheduled at 2025-07-28 11:53:03: Code: 396. DB::Exception: Limit for result exceeded, max bytes: 1.00 B, current bytes: 36.00 B. (TOO_MANY_ROWS_OR_BYTES), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, char const*&, ReadableSize&&, ReadableSize&&) @ 0x0000000013bd4eeb 4. /build/src/QueryPipeline/SizeLimits.cpp:43: DB::SizeLimits::check(unsigned long, unsigned long, char const*, int, int) const @ 0x0000000013bd48a1 5. /build/src/Processors/Transforms/LimitsCheckingTransform.cpp:45: DB::LimitsCheckingTransform::transform(DB::Chunk&) @ 0x0000000016c1d2fb 6. /build/src/Processors/ISimpleTransform.h:33: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000011a9a453 7. /build/src/Processors/ISimpleTransform.cpp:89: DB::ISimpleTransform::work() @ 0x000000001699fca0 8. /build/src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x00000000169bd00f 9. /build/src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x00000000169b2105 10. /build/src/Processors/Executors/PipelineExecutor.cpp:170: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x00000000169b16a7 11. /build/src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x00000000169c081c 12. /build/src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x00000000169c0978 13. /build/src/Dictionaries/FlatDictionary.cpp:502: DB::FlatDictionary::loadData() @ 0x0000000011b424cb 14. /build/src/Dictionaries/FlatDictionary.cpp:46: DB::FlatDictionary::FlatDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, DB::FlatDictionary::Configuration, std::shared_ptr) @ 0x0000000011b42111 15. /build/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:se190107]> (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) @ 0x0000000011b5d3e2 16. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000012d8a61d 17. /build/src/Interpreters/ExternalDictionariesLoader.cpp:47: DB::ExternalDictionariesLoader::createObject(String const&, Poco::Util::AbstractConfiguration const&, String const&, String const&) const @ 0x00000000148a6f44 18. /build/src/Interpreters/ExternalLoader.cpp:1522: DB::ExternalLoader::LoadingDispatcher::loadSingleObject(String const&, DB::ExternalLoader::ObjectConfig const&, std::shared_ptr) @ 0x00000000148b2ee8 19. /build/src/Interpreters/ExternalLoader.cpp:998: DB::ExternalLoader::LoadingDispatcher::doLoading(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr) @ 0x00000000148b197d 20. /build/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()() @ 0x00000000148b5991 21. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc3d92 22. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fcca080 23. ? @ 0x00007fbc6213eac3 24. ? @ 0x00007fbc621d0850 Job's origin stack trace: 0. /build/src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000000fc33b84 1. /build/src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000000fcc2ea7 2. /build/src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fcc535c 3. /build/src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000000fcc584d 4. /build/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&&) @ 0x00000000148b276d 5. /build/src/Interpreters/ExternalLoader.cpp:927: DB::ExternalLoader::LoadingDispatcher::startLoading(DB::ExternalLoader::LoadingDispatcher::Info&, bool, unsigned long) @ 0x00000000148b08fc 6. /build/src/Interpreters/ExternalLoader.cpp:833: DB::ExternalLoader::LoadingDispatcher::loadImpl(String const&, std::chrono::duration>, bool, std::unique_lock&)::'lambda'()::operator()() const @ 0x00000000148c0908 7. /build/contrib/llvm-project/libcxx/include/__condition_variable/condition_variable.h:146: DB::ExternalLoader::LoadingDispatcher::loadImpl(String const&, std::chrono::duration>, bool, std::unique_lock&) @ 0x00000000148c05bc 8. /build/src/Interpreters/ExternalLoader.cpp:604: DB::ExternalLoader::LoadResult DB::ExternalLoader::LoadingDispatcher::tryLoad(String const&, std::chrono::duration>) @ 0x00000000148accff 9. /build/src/Interpreters/ExternalLoader.cpp:1378: std::shared_ptr DB::ExternalLoader::load, void>(String const&) const @ 0x00000000148acf75 10. /build/src/Interpreters/ExternalDictionariesLoader.cpp:85: DB::ExternalDictionariesLoader::getDictionary(String const&, std::shared_ptr) const @ 0x00000000148a78c8 11. /build/src/Functions/FunctionsExternalDictionaries.h:76: DB::FunctionDictHelper::getDictionary(String const&) @ 0x000000000a1d046c 12. /build/src/Functions/FunctionsExternalDictionaries.h:426: DB::FunctionDictGetNoType<(DB::DictionaryGetFunctionType)0>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000a1cd55e 13. /build/src/Functions/FunctionsExternalDictionaries.h:831: DB::FunctionDictGetImpl, DB::NameDictGetUInt64, (DB::DictionaryGetFunctionType)0>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000a1e14a2 14. /build/src/Functions/IFunction.h:437: DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000a069f2a 15. /build/src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000012d9965a 16. /build/src/Functions/IFunction.cpp:351: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d93b02 17. /build/src/Functions/IFunction.cpp:177: DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d93698 18. /build/src/Functions/IFunction.cpp:343: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d93aad 19. /build/src/Functions/IFunction.cpp:420: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d95059 20. /build/src/Functions/IFunction.cpp:498: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d95c72 21. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3567: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000014034494 22. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3838: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000014019a9e 23. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3980: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000014018e31 24. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:4304: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000014042fa7 25. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5605: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000014013749 26. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000140127f9 27. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000014011fce 28. /build/src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000001406ce8a 29. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000014973b42 30. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000001497268d 31. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000014974d24 32. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001492924b 33. /build/src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88641 34. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 35. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 36. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 37. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 38. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 39. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 40. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 41. ? @ 0x00007fbc6213eac3 42. ? @ 0x00007fbc621d0850 (version 25.3.6.10636.altinitytest (altinity build)) 2025.07.28 11:52:57.532267 [ 17251 ] {794d2e6f-306e-4835-ad31-6d66aeb0a9e0} executeQuery: Code: 396. DB::Exception: Limit for result exceeded, max bytes: 1.00 B, current bytes: 36.00 B: In scope SELECT dictGetUInt64('ordinary_db.dict1', 'second_column', toUInt64(100500)). (TOO_MANY_ROWS_OR_BYTES) (version 25.3.6.10636.altinitytest (altinity build)) (from [::1]:47458) (comment: 01259_dictionary_custom_settings_ddl.sql) (query 8, line 33) (in query: SELECT dictGetUInt64('ordinary_db.dict1', 'second_column', toUInt64(100500));), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, char const*&, ReadableSize&&, ReadableSize&&) @ 0x0000000013bd4eeb 4. /build/src/QueryPipeline/SizeLimits.cpp:43: DB::SizeLimits::check(unsigned long, unsigned long, char const*, int, int) const @ 0x0000000013bd48a1 5. /build/src/Processors/Transforms/LimitsCheckingTransform.cpp:45: DB::LimitsCheckingTransform::transform(DB::Chunk&) @ 0x0000000016c1d2fb 6. /build/src/Processors/ISimpleTransform.h:33: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000011a9a453 7. /build/src/Processors/ISimpleTransform.cpp:89: DB::ISimpleTransform::work() @ 0x000000001699fca0 8. /build/src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x00000000169bd00f 9. /build/src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x00000000169b2105 10. /build/src/Processors/Executors/PipelineExecutor.cpp:170: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x00000000169b16a7 11. /build/src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x00000000169c081c 12. /build/src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x00000000169c0978 13. /build/src/Dictionaries/FlatDictionary.cpp:502: DB::FlatDictionary::loadData() @ 0x0000000011b424cb 14. /build/src/Dictionaries/FlatDictionary.cpp:46: DB::FlatDictionary::FlatDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, DB::FlatDictionary::Configuration, std::shared_ptr) @ 0x0000000011b42111 15. /build/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:se190107]> (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) @ 0x0000000011b5d3e2 16. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000012d8a61d 17. /build/src/Interpreters/ExternalDictionariesLoader.cpp:47: DB::ExternalDictionariesLoader::createObject(String const&, Poco::Util::AbstractConfiguration const&, String const&, String const&) const @ 0x00000000148a6f44 18. /build/src/Interpreters/ExternalLoader.cpp:1522: DB::ExternalLoader::LoadingDispatcher::loadSingleObject(String const&, DB::ExternalLoader::ObjectConfig const&, std::shared_ptr) @ 0x00000000148b2ee8 19. /build/src/Interpreters/ExternalLoader.cpp:998: DB::ExternalLoader::LoadingDispatcher::doLoading(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr) @ 0x00000000148b197d 20. /build/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()() @ 0x00000000148b5991 21. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc3d92 22. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fcca080 23. ? @ 0x00007fbc6213eac3 24. ? @ 0x00007fbc621d0850 2025.07.28 11:52:57.537122 [ 17251 ] {} TCPHandler: Code: 396. DB::Exception: Limit for result exceeded, max bytes: 1.00 B, current bytes: 36.00 B: In scope SELECT dictGetUInt64('ordinary_db.dict1', 'second_column', toUInt64(100500)). (TOO_MANY_ROWS_OR_BYTES), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, char const*&, ReadableSize&&, ReadableSize&&) @ 0x0000000013bd4eeb 4. /build/src/QueryPipeline/SizeLimits.cpp:43: DB::SizeLimits::check(unsigned long, unsigned long, char const*, int, int) const @ 0x0000000013bd48a1 5. /build/src/Processors/Transforms/LimitsCheckingTransform.cpp:45: DB::LimitsCheckingTransform::transform(DB::Chunk&) @ 0x0000000016c1d2fb 6. /build/src/Processors/ISimpleTransform.h:33: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000011a9a453 7. /build/src/Processors/ISimpleTransform.cpp:89: DB::ISimpleTransform::work() @ 0x000000001699fca0 8. /build/src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x00000000169bd00f 9. /build/src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x00000000169b2105 10. /build/src/Processors/Executors/PipelineExecutor.cpp:170: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x00000000169b16a7 11. /build/src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x00000000169c081c 12. /build/src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x00000000169c0978 13. /build/src/Dictionaries/FlatDictionary.cpp:502: DB::FlatDictionary::loadData() @ 0x0000000011b424cb 14. /build/src/Dictionaries/FlatDictionary.cpp:46: DB::FlatDictionary::FlatDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, DB::FlatDictionary::Configuration, std::shared_ptr) @ 0x0000000011b42111 15. /build/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:se190107]> (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) @ 0x0000000011b5d3e2 16. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000012d8a61d 17. /build/src/Interpreters/ExternalDictionariesLoader.cpp:47: DB::ExternalDictionariesLoader::createObject(String const&, Poco::Util::AbstractConfiguration const&, String const&, String const&) const @ 0x00000000148a6f44 18. /build/src/Interpreters/ExternalLoader.cpp:1522: DB::ExternalLoader::LoadingDispatcher::loadSingleObject(String const&, DB::ExternalLoader::ObjectConfig const&, std::shared_ptr) @ 0x00000000148b2ee8 19. /build/src/Interpreters/ExternalLoader.cpp:998: DB::ExternalLoader::LoadingDispatcher::doLoading(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr) @ 0x00000000148b197d 20. /build/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()() @ 0x00000000148b5991 21. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc3d92 22. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fcca080 23. ? @ 0x00007fbc6213eac3 24. ? @ 0x00007fbc621d0850 Job's origin stack trace: 0. /build/src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000000fc33b84 1. /build/src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000000fcc2ea7 2. /build/src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fcc535c 3. /build/src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000000fcc584d 4. /build/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&&) @ 0x00000000148b276d 5. /build/src/Interpreters/ExternalLoader.cpp:927: DB::ExternalLoader::LoadingDispatcher::startLoading(DB::ExternalLoader::LoadingDispatcher::Info&, bool, unsigned long) @ 0x00000000148b08fc 6. /build/src/Interpreters/ExternalLoader.cpp:833: DB::ExternalLoader::LoadingDispatcher::loadImpl(String const&, std::chrono::duration>, bool, std::unique_lock&)::'lambda'()::operator()() const @ 0x00000000148c0908 7. /build/contrib/llvm-project/libcxx/include/__condition_variable/condition_variable.h:146: DB::ExternalLoader::LoadingDispatcher::loadImpl(String const&, std::chrono::duration>, bool, std::unique_lock&) @ 0x00000000148c05bc 8. /build/src/Interpreters/ExternalLoader.cpp:604: DB::ExternalLoader::LoadResult DB::ExternalLoader::LoadingDispatcher::tryLoad(String const&, std::chrono::duration>) @ 0x00000000148accff 9. /build/src/Interpreters/ExternalLoader.cpp:1378: std::shared_ptr DB::ExternalLoader::load, void>(String const&) const @ 0x00000000148acf75 10. /build/src/Interpreters/ExternalDictionariesLoader.cpp:85: DB::ExternalDictionariesLoader::getDictionary(String const&, std::shared_ptr) const @ 0x00000000148a78c8 11. /build/src/Functions/FunctionsExternalDictionaries.h:76: DB::FunctionDictHelper::getDictionary(String const&) @ 0x000000000a1d046c 12. /build/src/Functions/FunctionsExternalDictionaries.h:426: DB::FunctionDictGetNoType<(DB::DictionaryGetFunctionType)0>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000a1cd55e 13. /build/src/Functions/FunctionsExternalDictionaries.h:831: DB::FunctionDictGetImpl, DB::NameDictGetUInt64, (DB::DictionaryGetFunctionType)0>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000a1e14a2 14. /build/src/Functions/IFunction.h:437: DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000a069f2a 15. /build/src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000012d9965a 16. /build/src/Functions/IFunction.cpp:351: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d93b02 17. /build/src/Functions/IFunction.cpp:177: DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d93698 18. /build/src/Functions/IFunction.cpp:343: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d93aad 19. /build/src/Functions/IFunction.cpp:420: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d95059 20. /build/src/Functions/IFunction.cpp:498: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d95c72 21. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3567: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000014034494 22. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3838: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000014019a9e 23. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3980: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000014018e31 24. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:4304: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000014042fa7 25. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5605: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000014013749 26. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000140127f9 27. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000014011fce 28. /build/src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000001406ce8a 29. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000014973b42 30. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000001497268d 31. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000014974d24 32. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001492924b 33. /build/src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88641 34. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 35. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 36. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 37. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 38. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 39. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 40. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 41. ? @ 0x00007fbc6213eac3 42. ? @ 0x00007fbc621d0850 2025.07.28 11:52:57.606287 [ 17207 ] {c88d86d9-1bf7-43f8-8834-04c687184b57} PushingToViews: Failed to push block to view test_5.v1 (4ae2feef-b6fa-47ac-b20c-744da14b2a0a), Stack size too large. Stack address: 0x7fb7fddf0000, frame address: 0x7fb7fe1ef100, stack size: 4198144, maximum stack size: 8388608 2025.07.28 11:52:57.616068 [ 17207 ] {c88d86d9-1bf7-43f8-8834-04c687184b57} PushingToViews: Failed to push block to view test_5.v2 (7c22a887-3ed3-40f1-a092-d92463e4b87b), Stack size too large. Stack address: 0x7fb7fddf0000, frame address: 0x7fb7fe1ef100, stack size: 4198144, maximum stack size: 8388608 2025.07.28 11:52:57.629914 [ 17207 ] {c88d86d9-1bf7-43f8-8834-04c687184b57} PushingToViews: Failed to push block to view test_5.v1 (4ae2feef-b6fa-47ac-b20c-744da14b2a0a), Stack size too large. Stack address: 0x7fb7fddf0000, frame address: 0x7fb7fe1ef100, stack size: 4198144, maximum stack size: 8388608 2025.07.28 11:52:57.630922 [ 17207 ] {c88d86d9-1bf7-43f8-8834-04c687184b57} PushingToViews: Failed to push block to view test_5.v2 (7c22a887-3ed3-40f1-a092-d92463e4b87b), Stack size too large. Stack address: 0x7fb7fddf0000, frame address: 0x7fb7fe1ef100, stack size: 4198144, maximum stack size: 8388608 2025.07.28 11:52:57.631166 [ 17251 ] {b700b645-f58c-4b05-81d7-b4d32295a6d8} executeQuery: Code: 62. DB::Exception: Cannot TRUNCATE dictionary. (SYNTAX_ERROR) (version 25.3.6.10636.altinitytest (altinity build)) (from [::1]:47458) (comment: 01259_dictionary_custom_settings_ddl.sql) (query 10, line 37) (in query: DROP DATABASE IF EXISTS ordinary_db;), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000000a074fcb 4. /build/src/Interpreters/InterpreterDropQuery.cpp:266: DB::InterpreterDropQuery::executeToTableImpl(std::shared_ptr const&, DB::ASTDropQuery&, std::shared_ptr&, StrongTypedef, DB::UUIDTag>&) @ 0x0000000014915b7b 5. /build/src/Interpreters/InterpreterDropQuery.cpp:461: DB::InterpreterDropQuery::executeToDatabaseImpl(DB::ASTDropQuery const&, std::shared_ptr&, std::vector, DB::UUIDTag>, std::allocator, DB::UUIDTag>>>&) @ 0x0000000014917707 6. /build/src/Interpreters/InterpreterDropQuery.cpp:363: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x0000000014913988 7. /build/src/Interpreters/InterpreterDropQuery.cpp:99: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000014913142 8. /build/src/Interpreters/InterpreterDropQuery.cpp:72: DB::InterpreterDropQuery::execute() @ 0x0000000014912b65 9. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88dc9 10. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 11. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 12. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 13. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 14. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 16. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 17. ? @ 0x00007fbc6213eac3 18. ? @ 0x00007fbc621d0850 2025.07.28 11:52:57.632491 [ 17207 ] {c88d86d9-1bf7-43f8-8834-04c687184b57} PushingToViews: Failed to push block to view test_5.v1 (4ae2feef-b6fa-47ac-b20c-744da14b2a0a), Stack size too large. Stack address: 0x7fb7fddf0000, frame address: 0x7fb7fe1ef100, stack size: 4198144, maximum stack size: 8388608 2025.07.28 11:52:57.633184 [ 17207 ] {c88d86d9-1bf7-43f8-8834-04c687184b57} PushingToViews: Failed to push block to view test_5.v2 (7c22a887-3ed3-40f1-a092-d92463e4b87b), Stack size too large. Stack address: 0x7fb7fddf0000, frame address: 0x7fb7fe1ef100, stack size: 4198144, maximum stack size: 8388608 2025.07.28 11:52:57.634218 [ 17207 ] {c88d86d9-1bf7-43f8-8834-04c687184b57} PushingToViews: Failed to push block to view test_5.v1 (4ae2feef-b6fa-47ac-b20c-744da14b2a0a), Stack size too large. Stack address: 0x7fb7fddf0000, frame address: 0x7fb7fe1ef100, stack size: 4198144, maximum stack size: 8388608 2025.07.28 11:52:57.636888 [ 17207 ] {c88d86d9-1bf7-43f8-8834-04c687184b57} PushingToViews: Failed to push block to view test_5.v2 (7c22a887-3ed3-40f1-a092-d92463e4b87b), Stack size too large. Stack address: 0x7fb7fddf0000, frame address: 0x7fb7fe1ef100, stack size: 4198144, maximum stack size: 8388608 2025.07.28 11:52:57.638134 [ 17207 ] {c88d86d9-1bf7-43f8-8834-04c687184b57} PushingToViews: Failed to push block to view test_5.v1 (4ae2feef-b6fa-47ac-b20c-744da14b2a0a), Stack size too large. Stack address: 0x7fb7fddf0000, frame address: 0x7fb7fe1ef100, stack size: 4198144, maximum stack size: 8388608 2025.07.28 11:52:57.639168 [ 17207 ] {c88d86d9-1bf7-43f8-8834-04c687184b57} PushingToViews: Failed to push block to view test_5.v2 (7c22a887-3ed3-40f1-a092-d92463e4b87b), Stack size too large. Stack address: 0x7fb7fddf0000, frame address: 0x7fb7fe1ef100, stack size: 4198144, maximum stack size: 8388608 2025.07.28 11:52:57.640130 [ 17207 ] {c88d86d9-1bf7-43f8-8834-04c687184b57} PushingToViews: Failed to push block to view test_5.v1 (4ae2feef-b6fa-47ac-b20c-744da14b2a0a), Stack size too large. Stack address: 0x7fb7fddf0000, frame address: 0x7fb7fe1ef100, stack size: 4198144, maximum stack size: 8388608 2025.07.28 11:52:57.641359 [ 17207 ] {c88d86d9-1bf7-43f8-8834-04c687184b57} PushingToViews: Failed to push block to view test_5.v2 (7c22a887-3ed3-40f1-a092-d92463e4b87b), Stack size too large. Stack address: 0x7fb7fddf0000, frame address: 0x7fb7fe1ef100, stack size: 4198144, maximum stack size: 8388608 2025.07.28 11:52:57.642261 [ 17207 ] {c88d86d9-1bf7-43f8-8834-04c687184b57} PushingToViews: Failed to push block to view test_5.v1 (4ae2feef-b6fa-47ac-b20c-744da14b2a0a), Stack size too large. Stack address: 0x7fb7fddf0000, frame address: 0x7fb7fe1ef100, stack size: 4198144, maximum stack size: 8388608 2025.07.28 11:52:57.643476 [ 17251 ] {} TCPHandler: Code: 62. DB::Exception: Cannot TRUNCATE dictionary. (SYNTAX_ERROR), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000000a074fcb 4. /build/src/Interpreters/InterpreterDropQuery.cpp:266: DB::InterpreterDropQuery::executeToTableImpl(std::shared_ptr const&, DB::ASTDropQuery&, std::shared_ptr&, StrongTypedef, DB::UUIDTag>&) @ 0x0000000014915b7b 5. /build/src/Interpreters/InterpreterDropQuery.cpp:461: DB::InterpreterDropQuery::executeToDatabaseImpl(DB::ASTDropQuery const&, std::shared_ptr&, std::vector, DB::UUIDTag>, std::allocator, DB::UUIDTag>>>&) @ 0x0000000014917707 6. /build/src/Interpreters/InterpreterDropQuery.cpp:363: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x0000000014913988 7. /build/src/Interpreters/InterpreterDropQuery.cpp:99: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000014913142 8. /build/src/Interpreters/InterpreterDropQuery.cpp:72: DB::InterpreterDropQuery::execute() @ 0x0000000014912b65 9. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88dc9 10. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 11. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 12. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 13. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 14. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 16. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 17. ? @ 0x00007fbc6213eac3 18. ? @ 0x00007fbc621d0850 2025.07.28 11:52:57.644090 [ 17207 ] {c88d86d9-1bf7-43f8-8834-04c687184b57} PushingToViews: Failed to push block to view test_5.v2 (7c22a887-3ed3-40f1-a092-d92463e4b87b), Stack size too large. Stack address: 0x7fb7fddf0000, frame address: 0x7fb7fe1ef100, stack size: 4198144, maximum stack size: 8388608 2025.07.28 11:52:57.645431 [ 17207 ] {c88d86d9-1bf7-43f8-8834-04c687184b57} PushingToViews: Failed to push block to view test_5.v1 (4ae2feef-b6fa-47ac-b20c-744da14b2a0a), Stack size too large. Stack address: 0x7fb7fddf0000, frame address: 0x7fb7fe1ef100, stack size: 4198144, maximum stack size: 8388608 2025.07.28 11:52:57.646389 [ 17207 ] {c88d86d9-1bf7-43f8-8834-04c687184b57} PushingToViews: Failed to push block to view test_5.v2 (7c22a887-3ed3-40f1-a092-d92463e4b87b), Stack size too large. Stack address: 0x7fb7fddf0000, frame address: 0x7fb7fe1ef100, stack size: 4198144, maximum stack size: 8388608 2025.07.28 11:52:57.647351 [ 17207 ] {c88d86d9-1bf7-43f8-8834-04c687184b57} PushingToViews: Failed to push block to view test_5.v1 (4ae2feef-b6fa-47ac-b20c-744da14b2a0a), Stack size too large. Stack address: 0x7fb7fddf0000, frame address: 0x7fb7fe1ef100, stack size: 4198144, maximum stack size: 8388608 2025.07.28 11:52:57.648300 [ 17207 ] {c88d86d9-1bf7-43f8-8834-04c687184b57} PushingToViews: Failed to push block to view test_5.v2 (7c22a887-3ed3-40f1-a092-d92463e4b87b), Stack size too large. Stack address: 0x7fb7fddf0000, frame address: 0x7fb7fe1ef100, stack size: 4198144, maximum stack size: 8388608 2025.07.28 11:52:57.650129 [ 17207 ] {c88d86d9-1bf7-43f8-8834-04c687184b57} PushingToViews: Failed to push block to view test_5.v1 (4ae2feef-b6fa-47ac-b20c-744da14b2a0a), Stack size too large. Stack address: 0x7fb7fddf0000, frame address: 0x7fb7fe1ef100, stack size: 4198144, maximum stack size: 8388608 2025.07.28 11:52:57.651930 [ 17207 ] {c88d86d9-1bf7-43f8-8834-04c687184b57} PushingToViews: Failed to push block to view test_5.v2 (7c22a887-3ed3-40f1-a092-d92463e4b87b), Stack size too large. Stack address: 0x7fb7fddf0000, frame address: 0x7fb7fe1ef100, stack size: 4198144, maximum stack size: 8388608 2025.07.28 11:52:57.653238 [ 17207 ] {c88d86d9-1bf7-43f8-8834-04c687184b57} PushingToViews: Failed to push block to view test_5.v1 (4ae2feef-b6fa-47ac-b20c-744da14b2a0a), Stack size too large. Stack address: 0x7fb7fddf0000, frame address: 0x7fb7fe1ef100, stack size: 4198144, maximum stack size: 8388608 2025.07.28 11:52:57.655006 [ 17207 ] {c88d86d9-1bf7-43f8-8834-04c687184b57} PushingToViews: Failed to push block to view test_5.v2 (7c22a887-3ed3-40f1-a092-d92463e4b87b), Stack size too large. Stack address: 0x7fb7fddf0000, frame address: 0x7fb7fe1ef100, stack size: 4198144, maximum stack size: 8388608 2025.07.28 11:52:57.656406 [ 17207 ] {c88d86d9-1bf7-43f8-8834-04c687184b57} PushingToViews: Failed to push block to view test_5.v1 (4ae2feef-b6fa-47ac-b20c-744da14b2a0a), Stack size too large. Stack address: 0x7fb7fddf0000, frame address: 0x7fb7fe1ef100, stack size: 4198144, maximum stack size: 8388608 2025.07.28 11:52:57.657380 [ 17207 ] {c88d86d9-1bf7-43f8-8834-04c687184b57} PushingToViews: Failed to push block to view test_5.v2 (7c22a887-3ed3-40f1-a092-d92463e4b87b), Stack size too large. Stack address: 0x7fb7fddf0000, frame address: 0x7fb7fe1ef100, stack size: 4198144, maximum stack size: 8388608 2025.07.28 11:52:57.658380 [ 17207 ] {c88d86d9-1bf7-43f8-8834-04c687184b57} PushingToViews: Failed to push block to view test_5.v1 (4ae2feef-b6fa-47ac-b20c-744da14b2a0a), Stack size too large. Stack address: 0x7fb7fddf0000, frame address: 0x7fb7fe1ef100, stack size: 4198144, maximum stack size: 8388608 2025.07.28 11:52:57.659319 [ 17207 ] {c88d86d9-1bf7-43f8-8834-04c687184b57} PushingToViews: Failed to push block to view test_5.v2 (7c22a887-3ed3-40f1-a092-d92463e4b87b), Stack size too large. Stack address: 0x7fb7fddf0000, frame address: 0x7fb7fe1ef100, stack size: 4198144, maximum stack size: 8388608 2025.07.28 11:52:57.662515 [ 17207 ] {c88d86d9-1bf7-43f8-8834-04c687184b57} PushingToViews: Failed to push block to view test_5.v1 (4ae2feef-b6fa-47ac-b20c-744da14b2a0a), Stack size too large. Stack address: 0x7fb7fddf0000, frame address: 0x7fb7fe1ef100, stack size: 4198144, maximum stack size: 8388608 2025.07.28 11:52:57.673767 [ 17207 ] {c88d86d9-1bf7-43f8-8834-04c687184b57} PushingToViews: Failed to push block to view test_5.v2 (7c22a887-3ed3-40f1-a092-d92463e4b87b), Stack size too large. Stack address: 0x7fb7fddf0000, frame address: 0x7fb7fe1ef100, stack size: 4198144, maximum stack size: 8388608 2025.07.28 11:52:57.676882 [ 17207 ] {c88d86d9-1bf7-43f8-8834-04c687184b57} PushingToViews: Failed to push block to view test_5.v1 (4ae2feef-b6fa-47ac-b20c-744da14b2a0a), Stack size too large. Stack address: 0x7fb7fddf0000, frame address: 0x7fb7fe1ef100, stack size: 4198144, maximum stack size: 8388608 2025.07.28 11:52:57.678130 [ 17207 ] {c88d86d9-1bf7-43f8-8834-04c687184b57} PushingToViews: Failed to push block to view test_5.v2 (7c22a887-3ed3-40f1-a092-d92463e4b87b), Stack size too large. Stack address: 0x7fb7fddf0000, frame address: 0x7fb7fe1ef100, stack size: 4198144, maximum stack size: 8388608 2025.07.28 11:52:57.681712 [ 17207 ] {c88d86d9-1bf7-43f8-8834-04c687184b57} PushingToViews: Failed to push block to view test_5.v1 (4ae2feef-b6fa-47ac-b20c-744da14b2a0a), Stack size too large. Stack address: 0x7fb7fddf0000, frame address: 0x7fb7fe1ef100, stack size: 4198144, maximum stack size: 8388608 2025.07.28 11:52:57.684908 [ 17207 ] {c88d86d9-1bf7-43f8-8834-04c687184b57} PushingToViews: Failed to push block to view test_5.v2 (7c22a887-3ed3-40f1-a092-d92463e4b87b), Stack size too large. Stack address: 0x7fb7fddf0000, frame address: 0x7fb7fe1ef100, stack size: 4198144, maximum stack size: 8388608 2025.07.28 11:52:57.694654 [ 17207 ] {c88d86d9-1bf7-43f8-8834-04c687184b57} PushingToViews: Failed to push block to view test_5.v1 (4ae2feef-b6fa-47ac-b20c-744da14b2a0a), Stack size too large. Stack address: 0x7fb7fddf0000, frame address: 0x7fb7fe1ef100, stack size: 4198144, maximum stack size: 8388608 2025.07.28 11:52:57.698386 [ 17207 ] {c88d86d9-1bf7-43f8-8834-04c687184b57} PushingToViews: Failed to push block to view test_5.v2 (7c22a887-3ed3-40f1-a092-d92463e4b87b), Stack size too large. Stack address: 0x7fb7fddf0000, frame address: 0x7fb7fe1ef100, stack size: 4198144, maximum stack size: 8388608 2025.07.28 11:52:57.705458 [ 17207 ] {c88d86d9-1bf7-43f8-8834-04c687184b57} PushingToViews: Failed to push block to view test_5.v1 (4ae2feef-b6fa-47ac-b20c-744da14b2a0a), Stack size too large. Stack address: 0x7fb7fddf0000, frame address: 0x7fb7fe1ef100, stack size: 4198144, maximum stack size: 8388608 2025.07.28 11:52:57.714573 [ 17207 ] {c88d86d9-1bf7-43f8-8834-04c687184b57} PushingToViews: Failed to push block to view test_5.v2 (7c22a887-3ed3-40f1-a092-d92463e4b87b), Stack size too large. Stack address: 0x7fb7fddf0000, frame address: 0x7fb7fe1ef100, stack size: 4198144, maximum stack size: 8388608 2025.07.28 11:52:57.716270 [ 17207 ] {c88d86d9-1bf7-43f8-8834-04c687184b57} PushingToViews: Failed to push block to view test_5.v1 (4ae2feef-b6fa-47ac-b20c-744da14b2a0a), Stack size too large. Stack address: 0x7fb7fddf0000, frame address: 0x7fb7fe1ef100, stack size: 4198144, maximum stack size: 8388608 2025.07.28 11:52:57.731250 [ 17207 ] {c88d86d9-1bf7-43f8-8834-04c687184b57} PushingToViews: Failed to push block to view test_5.v2 (7c22a887-3ed3-40f1-a092-d92463e4b87b), Stack size too large. Stack address: 0x7fb7fddf0000, frame address: 0x7fb7fe1ef100, stack size: 4198144, maximum stack size: 8388608 2025.07.28 11:52:57.734265 [ 17207 ] {c88d86d9-1bf7-43f8-8834-04c687184b57} PushingToViews: Failed to push block to view test_5.v1 (4ae2feef-b6fa-47ac-b20c-744da14b2a0a), Stack size too large. Stack address: 0x7fb7fddf0000, frame address: 0x7fb7fe1ef100, stack size: 4198144, maximum stack size: 8388608 2025.07.28 11:52:57.752139 [ 17207 ] {c88d86d9-1bf7-43f8-8834-04c687184b57} PushingToViews: Failed to push block to view test_5.v2 (7c22a887-3ed3-40f1-a092-d92463e4b87b), Stack size too large. Stack address: 0x7fb7fddf0000, frame address: 0x7fb7fe1ef100, stack size: 4198144, maximum stack size: 8388608 2025.07.28 11:52:57.760781 [ 17207 ] {c88d86d9-1bf7-43f8-8834-04c687184b57} PushingToViews: Failed to push block to view test_5.v1 (4ae2feef-b6fa-47ac-b20c-744da14b2a0a), Stack size too large. Stack address: 0x7fb7fddf0000, frame address: 0x7fb7fe1ef100, stack size: 4198144, maximum stack size: 8388608 2025.07.28 11:52:57.762616 [ 17207 ] {c88d86d9-1bf7-43f8-8834-04c687184b57} PushingToViews: Failed to push block to view test_5.v2 (7c22a887-3ed3-40f1-a092-d92463e4b87b), Stack size too large. Stack address: 0x7fb7fddf0000, frame address: 0x7fb7fe1ef100, stack size: 4198144, maximum stack size: 8388608 2025.07.28 11:52:57.764609 [ 17207 ] {c88d86d9-1bf7-43f8-8834-04c687184b57} PushingToViews: Failed to push block to view test_5.v1 (4ae2feef-b6fa-47ac-b20c-744da14b2a0a), Stack size too large. Stack address: 0x7fb7fddf0000, frame address: 0x7fb7fe1ef100, stack size: 4198144, maximum stack size: 8388608 2025.07.28 11:52:57.781426 [ 17207 ] {c88d86d9-1bf7-43f8-8834-04c687184b57} PushingToViews: Failed to push block to view test_5.v2 (7c22a887-3ed3-40f1-a092-d92463e4b87b), Stack size too large. Stack address: 0x7fb7fddf0000, frame address: 0x7fb7fe1ef100, stack size: 4198144, maximum stack size: 8388608 2025.07.28 11:52:57.784435 [ 17207 ] {c88d86d9-1bf7-43f8-8834-04c687184b57} PushingToViews: Failed to push block to view test_5.v1 (4ae2feef-b6fa-47ac-b20c-744da14b2a0a), Stack size too large. Stack address: 0x7fb7fddf0000, frame address: 0x7fb7fe1ef100, stack size: 4198144, maximum stack size: 8388608 2025.07.28 11:52:57.786004 [ 17207 ] {c88d86d9-1bf7-43f8-8834-04c687184b57} PushingToViews: Failed to push block to view test_5.v2 (7c22a887-3ed3-40f1-a092-d92463e4b87b), Stack size too large. Stack address: 0x7fb7fddf0000, frame address: 0x7fb7fe1ef100, stack size: 4198144, maximum stack size: 8388608 2025.07.28 11:52:57.792067 [ 17207 ] {c88d86d9-1bf7-43f8-8834-04c687184b57} PushingToViews: Failed to push block to view test_5.v1 (4ae2feef-b6fa-47ac-b20c-744da14b2a0a), Stack size too large. Stack address: 0x7fb7fddf0000, frame address: 0x7fb7fe1ef100, stack size: 4198144, maximum stack size: 8388608 2025.07.28 11:52:57.803054 [ 17207 ] {c88d86d9-1bf7-43f8-8834-04c687184b57} PushingToViews: Failed to push block to view test_5.v2 (7c22a887-3ed3-40f1-a092-d92463e4b87b), Stack size too large. Stack address: 0x7fb7fddf0000, frame address: 0x7fb7fe1ef100, stack size: 4198144, maximum stack size: 8388608 2025.07.28 11:52:57.815790 [ 17207 ] {c88d86d9-1bf7-43f8-8834-04c687184b57} PushingToViews: Failed to push block to view test_5.v1 (4ae2feef-b6fa-47ac-b20c-744da14b2a0a), Stack size too large. Stack address: 0x7fb7fddf0000, frame address: 0x7fb7fe1ef100, stack size: 4198144, maximum stack size: 8388608 2025.07.28 11:52:57.824105 [ 17207 ] {c88d86d9-1bf7-43f8-8834-04c687184b57} PushingToViews: Failed to push block to view test_5.v2 (7c22a887-3ed3-40f1-a092-d92463e4b87b), Stack size too large. Stack address: 0x7fb7fddf0000, frame address: 0x7fb7fe1ef100, stack size: 4198144, maximum stack size: 8388608 2025.07.28 11:52:57.829319 [ 17207 ] {c88d86d9-1bf7-43f8-8834-04c687184b57} PushingToViews: Failed to push block to view test_5.v1 (4ae2feef-b6fa-47ac-b20c-744da14b2a0a), Stack size too large. Stack address: 0x7fb7fddf0000, frame address: 0x7fb7fe1ef100, stack size: 4198144, maximum stack size: 8388608 2025.07.28 11:52:57.830872 [ 17207 ] {c88d86d9-1bf7-43f8-8834-04c687184b57} PushingToViews: Failed to push block to view test_5.v2 (7c22a887-3ed3-40f1-a092-d92463e4b87b), Stack size too large. Stack address: 0x7fb7fddf0000, frame address: 0x7fb7fe1ef100, stack size: 4198144, maximum stack size: 8388608 2025.07.28 11:52:57.832826 [ 17207 ] {c88d86d9-1bf7-43f8-8834-04c687184b57} PushingToViews: Failed to push block to view test_5.v1 (4ae2feef-b6fa-47ac-b20c-744da14b2a0a), Stack size too large. Stack address: 0x7fb7fddf0000, frame address: 0x7fb7fe1ef100, stack size: 4198144, maximum stack size: 8388608 2025.07.28 11:52:57.834804 [ 17207 ] {c88d86d9-1bf7-43f8-8834-04c687184b57} PushingToViews: Failed to push block to view test_5.v2 (7c22a887-3ed3-40f1-a092-d92463e4b87b), Stack size too large. Stack address: 0x7fb7fddf0000, frame address: 0x7fb7fe1ef100, stack size: 4198144, maximum stack size: 8388608 2025.07.28 11:52:57.840684 [ 17207 ] {c88d86d9-1bf7-43f8-8834-04c687184b57} PushingToViews: Failed to push block to view test_5.v1 (4ae2feef-b6fa-47ac-b20c-744da14b2a0a), Stack size too large. Stack address: 0x7fb7fddf0000, frame address: 0x7fb7fe1ef100, stack size: 4198144, maximum stack size: 8388608 2025.07.28 11:52:57.842290 [ 17207 ] {c88d86d9-1bf7-43f8-8834-04c687184b57} PushingToViews: Failed to push block to view test_5.v2 (7c22a887-3ed3-40f1-a092-d92463e4b87b), Stack size too large. Stack address: 0x7fb7fddf0000, frame address: 0x7fb7fe1ef100, stack size: 4198144, maximum stack size: 8388608 2025.07.28 11:52:57.850694 [ 3977 ] {} test_13.rmt2 (7f9b740d-015c-470e-8cc6-8ba33be0dc63): auto DB::StorageReplicatedMergeTree::processQueueEntry(ReplicatedMergeTreeQueue::SelectedEntryPtr)::(anonymous class)::operator()(LogEntryPtr &) const: Code: 86. DB::HTTPException: Received error from remote server http://146b4357c08d:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Ftest%2F01165%2Ftest_13%2Frmt%2Freplicas%2F1&part=20250728_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.6.10636.altinitytest (altinity build)) '. (RECEIVED_ERROR_FROM_REMOTE_IO_SERVER), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.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 const&, int&&, String const&, unsigned long&&, String const&) @ 0x000000000feda8d9 4. /build/src/IO/HTTPCommon.cpp:104: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x000000000feda6e2 5. /build/src/IO/HTTPCommon.cpp:93: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x000000000feda537 6. /build/src/IO/ReadWriteBufferFromHTTP.cpp:277: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x000000001184a4c4 7. /build/src/IO/ReadWriteBufferFromHTTP.cpp:285: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x000000001184a615 8. /build/src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x000000001184ae59 9. /build/src/IO/ReadWriteBufferFromHTTP.cpp:472: void std::__function::__policy_invoker::__call_impl[abi:se190107]>(std::__function::__policy_storage const*) @ 0x000000001184cedd 10. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001184858b 11. /build/src/IO/ReadWriteBufferFromHTTP.cpp:465: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x000000001184bf0b 12. /build/src/IO/ReadBuffer.h:60: DB::ReadBuffer::next() @ 0x000000000a148c7b 13. /build/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) @ 0x0000000011849fb2 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]>&)>&, 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&) @ 0x0000000011841980 15. /build/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) @ 0x000000001621208e 16. /build/src/Storages/StorageReplicatedMergeTree.cpp:5228: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl[abi:se190107] const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000015f9a5fe 17. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000015ed8bfd 18. /build/src/Storages/StorageReplicatedMergeTree.cpp:2514: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x0000000015ec9aab 19. /build/src/Storages/StorageReplicatedMergeTree.cpp:2349: DB::StorageReplicatedMergeTree::executeLogEntry(DB::ReplicatedMergeTreeLogEntry&) @ 0x0000000015eba91b 20. /build/src/Storages/StorageReplicatedMergeTree.cpp:3876: bool std::__function::__policy_invoker&)>::__call_impl[abi:se190107])::$_1, bool (std::shared_ptr&)>>(std::__function::__policy_storage const*, std::shared_ptr&) @ 0x0000000015f9837e 21. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000165d6fc3 22. /build/src/Storages/StorageReplicatedMergeTree.cpp:3872: DB::StorageReplicatedMergeTree::processQueueEntry(std::shared_ptr) @ 0x0000000015efc18a 23. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001624c1b2 24. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000162f9c70 25. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x00000000162fa55a 26. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc6653 27. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000000fccc4c3 28. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc3d92 29. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fcca080 30. ? @ 0x00007fbc6213eac3 31. ? @ 0x00007fbc621d0850 (version 25.3.6.10636.altinitytest (altinity build)) 2025.07.28 11:52:57.941426 [ 17207 ] {c88d86d9-1bf7-43f8-8834-04c687184b57} PushingToViews: Failed to push block to view test_5.v1 (4ae2feef-b6fa-47ac-b20c-744da14b2a0a), Stack size too large. Stack address: 0x7fb7fddf0000, frame address: 0x7fb7fe1ef100, stack size: 4198144, maximum stack size: 8388608 2025.07.28 11:52:57.942970 [ 17207 ] {c88d86d9-1bf7-43f8-8834-04c687184b57} PushingToViews: Failed to push block to view test_5.v2 (7c22a887-3ed3-40f1-a092-d92463e4b87b), Stack size too large. Stack address: 0x7fb7fddf0000, frame address: 0x7fb7fe1ef100, stack size: 4198144, maximum stack size: 8388608 2025.07.28 11:52:57.948054 [ 17207 ] {c88d86d9-1bf7-43f8-8834-04c687184b57} PushingToViews: Failed to push block to view test_5.v1 (4ae2feef-b6fa-47ac-b20c-744da14b2a0a), Stack size too large. Stack address: 0x7fb7fddf0000, frame address: 0x7fb7fe1ef100, stack size: 4198144, maximum stack size: 8388608 2025.07.28 11:52:57.949059 [ 17207 ] {c88d86d9-1bf7-43f8-8834-04c687184b57} PushingToViews: Failed to push block to view test_5.v2 (7c22a887-3ed3-40f1-a092-d92463e4b87b), Stack size too large. Stack address: 0x7fb7fddf0000, frame address: 0x7fb7fe1ef100, stack size: 4198144, maximum stack size: 8388608 2025.07.28 11:52:57.950551 [ 17207 ] {c88d86d9-1bf7-43f8-8834-04c687184b57} PushingToViews: Failed to push block to view test_5.v1 (4ae2feef-b6fa-47ac-b20c-744da14b2a0a), Stack size too large. Stack address: 0x7fb7fddf0000, frame address: 0x7fb7fe1ef100, stack size: 4198144, maximum stack size: 8388608 2025.07.28 11:52:57.951492 [ 17207 ] {c88d86d9-1bf7-43f8-8834-04c687184b57} PushingToViews: Failed to push block to view test_5.v2 (7c22a887-3ed3-40f1-a092-d92463e4b87b), Stack size too large. Stack address: 0x7fb7fddf0000, frame address: 0x7fb7fe1ef100, stack size: 4198144, maximum stack size: 8388608 2025.07.28 11:52:57.952671 [ 17207 ] {c88d86d9-1bf7-43f8-8834-04c687184b57} PushingToViews: Failed to push block to view test_5.v1 (4ae2feef-b6fa-47ac-b20c-744da14b2a0a), Stack size too large. Stack address: 0x7fb7fddf0000, frame address: 0x7fb7fe1ef100, stack size: 4198144, maximum stack size: 8388608 2025.07.28 11:52:57.953702 [ 17207 ] {c88d86d9-1bf7-43f8-8834-04c687184b57} PushingToViews: Failed to push block to view test_5.v2 (7c22a887-3ed3-40f1-a092-d92463e4b87b), Stack size too large. Stack address: 0x7fb7fddf0000, frame address: 0x7fb7fe1ef100, stack size: 4198144, maximum stack size: 8388608 2025.07.28 11:52:57.955314 [ 17207 ] {c88d86d9-1bf7-43f8-8834-04c687184b57} PushingToViews: Failed to push block to view test_5.v1 (4ae2feef-b6fa-47ac-b20c-744da14b2a0a), Stack size too large. Stack address: 0x7fb7fddf0000, frame address: 0x7fb7fe1ef100, stack size: 4198144, maximum stack size: 8388608 2025.07.28 11:52:57.956450 [ 17207 ] {c88d86d9-1bf7-43f8-8834-04c687184b57} PushingToViews: Failed to push block to view test_5.v2 (7c22a887-3ed3-40f1-a092-d92463e4b87b), Stack size too large. Stack address: 0x7fb7fddf0000, frame address: 0x7fb7fe1ef100, stack size: 4198144, maximum stack size: 8388608 2025.07.28 11:52:57.957377 [ 17207 ] {c88d86d9-1bf7-43f8-8834-04c687184b57} PushingToViews: Failed to push block to view test_5.v1 (4ae2feef-b6fa-47ac-b20c-744da14b2a0a), Stack size too large. Stack address: 0x7fb7fddf0000, frame address: 0x7fb7fe1ef100, stack size: 4198144, maximum stack size: 8388608 2025.07.28 11:52:57.959319 [ 17207 ] {c88d86d9-1bf7-43f8-8834-04c687184b57} PushingToViews: Failed to push block to view test_5.v2 (7c22a887-3ed3-40f1-a092-d92463e4b87b), Stack size too large. Stack address: 0x7fb7fddf0000, frame address: 0x7fb7fe1ef100, stack size: 4198144, maximum stack size: 8388608 2025.07.28 11:52:57.964962 [ 17207 ] {c88d86d9-1bf7-43f8-8834-04c687184b57} PushingToViews: Failed to push block to view test_5.v1 (4ae2feef-b6fa-47ac-b20c-744da14b2a0a), Stack size too large. Stack address: 0x7fb7fddf0000, frame address: 0x7fb7fe1ef100, stack size: 4198144, maximum stack size: 8388608 2025.07.28 11:52:57.967927 [ 17207 ] {c88d86d9-1bf7-43f8-8834-04c687184b57} PushingToViews: Failed to push block to view test_5.v2 (7c22a887-3ed3-40f1-a092-d92463e4b87b), Stack size too large. Stack address: 0x7fb7fddf0000, frame address: 0x7fb7fe1ef100, stack size: 4198144, maximum stack size: 8388608 2025.07.28 11:52:57.977215 [ 17207 ] {c88d86d9-1bf7-43f8-8834-04c687184b57} PushingToViews: Failed to push block to view test_5.v1 (4ae2feef-b6fa-47ac-b20c-744da14b2a0a), Stack size too large. Stack address: 0x7fb7fddf0000, frame address: 0x7fb7fe1ef100, stack size: 4198144, maximum stack size: 8388608 2025.07.28 11:52:57.978723 [ 17207 ] {c88d86d9-1bf7-43f8-8834-04c687184b57} PushingToViews: Failed to push block to view test_5.v2 (7c22a887-3ed3-40f1-a092-d92463e4b87b), Stack size too large. Stack address: 0x7fb7fddf0000, frame address: 0x7fb7fe1ef100, stack size: 4198144, maximum stack size: 8388608 2025.07.28 11:52:57.985136 [ 17207 ] {c88d86d9-1bf7-43f8-8834-04c687184b57} PushingToViews: Failed to push block to view test_5.v1 (4ae2feef-b6fa-47ac-b20c-744da14b2a0a), Stack size too large. Stack address: 0x7fb7fddf0000, frame address: 0x7fb7fe1ef100, stack size: 4198144, maximum stack size: 8388608 2025.07.28 11:52:57.987249 [ 17207 ] {c88d86d9-1bf7-43f8-8834-04c687184b57} PushingToViews: Failed to push block to view test_5.v2 (7c22a887-3ed3-40f1-a092-d92463e4b87b), Stack size too large. Stack address: 0x7fb7fddf0000, frame address: 0x7fb7fe1ef100, stack size: 4198144, maximum stack size: 8388608 2025.07.28 11:52:57.988600 [ 17207 ] {c88d86d9-1bf7-43f8-8834-04c687184b57} PushingToViews: Failed to push block to view test_5.v1 (4ae2feef-b6fa-47ac-b20c-744da14b2a0a), Stack size too large. Stack address: 0x7fb7fddf0000, frame address: 0x7fb7fe1ef100, stack size: 4198144, maximum stack size: 8388608 2025.07.28 11:52:57.999252 [ 17207 ] {c88d86d9-1bf7-43f8-8834-04c687184b57} PushingToViews: Failed to push block to view test_5.v2 (7c22a887-3ed3-40f1-a092-d92463e4b87b), Stack size too large. Stack address: 0x7fb7fddf0000, frame address: 0x7fb7fe1ef100, stack size: 4198144, maximum stack size: 8388608 2025.07.28 11:52:58.006517 [ 17207 ] {c88d86d9-1bf7-43f8-8834-04c687184b57} PushingToViews: Failed to push block to view test_5.v1 (4ae2feef-b6fa-47ac-b20c-744da14b2a0a), Stack size too large. Stack address: 0x7fb7fddf0000, frame address: 0x7fb7fe1ef100, stack size: 4198144, maximum stack size: 8388608 2025.07.28 11:52:58.009347 [ 17207 ] {c88d86d9-1bf7-43f8-8834-04c687184b57} PushingToViews: Failed to push block to view test_5.v2 (7c22a887-3ed3-40f1-a092-d92463e4b87b), Stack size too large. Stack address: 0x7fb7fddf0000, frame address: 0x7fb7fe1ef100, stack size: 4198144, maximum stack size: 8388608 2025.07.28 11:52:58.011837 [ 17207 ] {c88d86d9-1bf7-43f8-8834-04c687184b57} PushingToViews: Failed to push block to view test_5.v1 (4ae2feef-b6fa-47ac-b20c-744da14b2a0a), Stack size too large. Stack address: 0x7fb7fddf0000, frame address: 0x7fb7fe1ef100, stack size: 4198144, maximum stack size: 8388608 2025.07.28 11:52:58.117334 [ 17207 ] {c88d86d9-1bf7-43f8-8834-04c687184b57} PushingToViews: Failed to push block to view test_5.v2 (7c22a887-3ed3-40f1-a092-d92463e4b87b), Stack size too large. Stack address: 0x7fb7fddf0000, frame address: 0x7fb7fe1ef100, stack size: 4198144, maximum stack size: 8388608 2025.07.28 11:52:58.118010 [ 17207 ] {c88d86d9-1bf7-43f8-8834-04c687184b57} PushingToViews: Failed to push block to view test_5.v1 (4ae2feef-b6fa-47ac-b20c-744da14b2a0a), Stack size too large. Stack address: 0x7fb7fddf0000, frame address: 0x7fb7fe1ef100, stack size: 4198144, maximum stack size: 8388608 2025.07.28 11:52:58.127299 [ 17207 ] {c88d86d9-1bf7-43f8-8834-04c687184b57} PushingToViews: Failed to push block to view test_5.v2 (7c22a887-3ed3-40f1-a092-d92463e4b87b), Stack size too large. Stack address: 0x7fb7fddf0000, frame address: 0x7fb7fe1ef100, stack size: 4198144, maximum stack size: 8388608 2025.07.28 11:52:58.128701 [ 17207 ] {c88d86d9-1bf7-43f8-8834-04c687184b57} PushingToViews: Failed to push block to view test_5.v1 (4ae2feef-b6fa-47ac-b20c-744da14b2a0a), Stack size too large. Stack address: 0x7fb7fddf0000, frame address: 0x7fb7fe1ef100, stack size: 4198144, maximum stack size: 8388608 2025.07.28 11:52:58.129559 [ 17207 ] {c88d86d9-1bf7-43f8-8834-04c687184b57} PushingToViews: Failed to push block to view test_5.v2 (7c22a887-3ed3-40f1-a092-d92463e4b87b), Stack size too large. Stack address: 0x7fb7fddf0000, frame address: 0x7fb7fe1ef100, stack size: 4198144, maximum stack size: 8388608 2025.07.28 11:52:58.130171 [ 17207 ] {c88d86d9-1bf7-43f8-8834-04c687184b57} PushingToViews: Failed to push block to view test_5.v1 (4ae2feef-b6fa-47ac-b20c-744da14b2a0a), Stack size too large. Stack address: 0x7fb7fddf0000, frame address: 0x7fb7fe1ef100, stack size: 4198144, maximum stack size: 8388608 2025.07.28 11:52:58.131902 [ 17207 ] {c88d86d9-1bf7-43f8-8834-04c687184b57} PushingToViews: Failed to push block to view test_5.v2 (7c22a887-3ed3-40f1-a092-d92463e4b87b), Stack size too large. Stack address: 0x7fb7fddf0000, frame address: 0x7fb7fe1ef100, stack size: 4198144, maximum stack size: 8388608 2025.07.28 11:52:58.132530 [ 17207 ] {c88d86d9-1bf7-43f8-8834-04c687184b57} PushingToViews: Failed to push block to view test_5.v1 (4ae2feef-b6fa-47ac-b20c-744da14b2a0a), Stack size too large. Stack address: 0x7fb7fddf0000, frame address: 0x7fb7fe1ef100, stack size: 4198144, maximum stack size: 8388608 2025.07.28 11:52:58.133401 [ 17207 ] {c88d86d9-1bf7-43f8-8834-04c687184b57} PushingToViews: Failed to push block to view test_5.v2 (7c22a887-3ed3-40f1-a092-d92463e4b87b), Stack size too large. Stack address: 0x7fb7fddf0000, frame address: 0x7fb7fe1ef100, stack size: 4198144, maximum stack size: 8388608 2025.07.28 11:52:58.134084 [ 17207 ] {c88d86d9-1bf7-43f8-8834-04c687184b57} PushingToViews: Failed to push block to view test_5.v1 (4ae2feef-b6fa-47ac-b20c-744da14b2a0a), Stack size too large. Stack address: 0x7fb7fddf0000, frame address: 0x7fb7fe1ef100, stack size: 4198144, maximum stack size: 8388608 2025.07.28 11:52:58.135336 [ 17207 ] {c88d86d9-1bf7-43f8-8834-04c687184b57} PushingToViews: Failed to push block to view test_5.v2 (7c22a887-3ed3-40f1-a092-d92463e4b87b), Stack size too large. Stack address: 0x7fb7fddf0000, frame address: 0x7fb7fe1ef100, stack size: 4198144, maximum stack size: 8388608 2025.07.28 11:52:58.135974 [ 17207 ] {c88d86d9-1bf7-43f8-8834-04c687184b57} PushingToViews: Failed to push block to view test_5.v1 (4ae2feef-b6fa-47ac-b20c-744da14b2a0a), Stack size too large. Stack address: 0x7fb7fddf0000, frame address: 0x7fb7fe1ef100, stack size: 4198144, maximum stack size: 8388608 2025.07.28 11:52:58.140969 [ 17207 ] {c88d86d9-1bf7-43f8-8834-04c687184b57} PushingToViews: Failed to push block to view test_5.v2 (7c22a887-3ed3-40f1-a092-d92463e4b87b), Stack size too large. Stack address: 0x7fb7fddf0000, frame address: 0x7fb7fe1ef100, stack size: 4198144, maximum stack size: 8388608 2025.07.28 11:52:58.147182 [ 17207 ] {c88d86d9-1bf7-43f8-8834-04c687184b57} PushingToViews: Failed to push block to view test_5.v1 (4ae2feef-b6fa-47ac-b20c-744da14b2a0a), Stack size too large. Stack address: 0x7fb7fddf0000, frame address: 0x7fb7fe1ef100, stack size: 4198144, maximum stack size: 8388608 2025.07.28 11:52:58.148136 [ 17207 ] {c88d86d9-1bf7-43f8-8834-04c687184b57} PushingToViews: Failed to push block to view test_5.v2 (7c22a887-3ed3-40f1-a092-d92463e4b87b), Stack size too large. Stack address: 0x7fb7fddf0000, frame address: 0x7fb7fe1ef100, stack size: 4198144, maximum stack size: 8388608 2025.07.28 11:52:58.155973 [ 17207 ] {c88d86d9-1bf7-43f8-8834-04c687184b57} PushingToViews: Failed to push block to view test_5.v1 (4ae2feef-b6fa-47ac-b20c-744da14b2a0a), Stack size too large. Stack address: 0x7fb7fddf0000, frame address: 0x7fb7fe1ef100, stack size: 4198144, maximum stack size: 8388608 2025.07.28 11:52:58.161183 [ 17207 ] {c88d86d9-1bf7-43f8-8834-04c687184b57} PushingToViews: Failed to push block to view test_5.v2 (7c22a887-3ed3-40f1-a092-d92463e4b87b), Stack size too large. Stack address: 0x7fb7fddf0000, frame address: 0x7fb7fe1ef100, stack size: 4198144, maximum stack size: 8388608 2025.07.28 11:52:58.162428 [ 17207 ] {c88d86d9-1bf7-43f8-8834-04c687184b57} PushingToViews: Failed to push block to view test_5.v1 (4ae2feef-b6fa-47ac-b20c-744da14b2a0a), Stack size too large. Stack address: 0x7fb7fddf0000, frame address: 0x7fb7fe1ef100, stack size: 4198144, maximum stack size: 8388608 2025.07.28 11:52:58.167671 [ 17207 ] {c88d86d9-1bf7-43f8-8834-04c687184b57} PushingToViews: Failed to push block to view test_5.v2 (7c22a887-3ed3-40f1-a092-d92463e4b87b), Stack size too large. Stack address: 0x7fb7fddf0000, frame address: 0x7fb7fe1ef100, stack size: 4198144, maximum stack size: 8388608 2025.07.28 11:52:58.173226 [ 17207 ] {c88d86d9-1bf7-43f8-8834-04c687184b57} PushingToViews: Failed to push block to view test_5.v1 (4ae2feef-b6fa-47ac-b20c-744da14b2a0a), Stack size too large. Stack address: 0x7fb7fddf0000, frame address: 0x7fb7fe1ef100, stack size: 4198144, maximum stack size: 8388608 2025.07.28 11:52:58.177551 [ 17207 ] {c88d86d9-1bf7-43f8-8834-04c687184b57} PushingToViews: Failed to push block to view test_5.v2 (7c22a887-3ed3-40f1-a092-d92463e4b87b), Stack size too large. Stack address: 0x7fb7fddf0000, frame address: 0x7fb7fe1ef100, stack size: 4198144, maximum stack size: 8388608 2025.07.28 11:52:58.178727 [ 17207 ] {c88d86d9-1bf7-43f8-8834-04c687184b57} PushingToViews: Failed to push block to view test_5.v1 (4ae2feef-b6fa-47ac-b20c-744da14b2a0a), Stack size too large. Stack address: 0x7fb7fddf0000, frame address: 0x7fb7fe1ef100, stack size: 4198144, maximum stack size: 8388608 2025.07.28 11:52:58.179632 [ 17207 ] {c88d86d9-1bf7-43f8-8834-04c687184b57} PushingToViews: Failed to push block to view test_5.v2 (7c22a887-3ed3-40f1-a092-d92463e4b87b), Stack size too large. Stack address: 0x7fb7fddf0000, frame address: 0x7fb7fe1ef100, stack size: 4198144, maximum stack size: 8388608 2025.07.28 11:52:58.184808 [ 17207 ] {c88d86d9-1bf7-43f8-8834-04c687184b57} PushingToViews: Failed to push block to view test_5.v1 (4ae2feef-b6fa-47ac-b20c-744da14b2a0a), Stack size too large. Stack address: 0x7fb7fddf0000, frame address: 0x7fb7fe1ef100, stack size: 4198144, maximum stack size: 8388608 2025.07.28 11:52:58.188859 [ 17207 ] {c88d86d9-1bf7-43f8-8834-04c687184b57} PushingToViews: Failed to push block to view test_5.v2 (7c22a887-3ed3-40f1-a092-d92463e4b87b), Stack size too large. Stack address: 0x7fb7fddf0000, frame address: 0x7fb7fe1ef100, stack size: 4198144, maximum stack size: 8388608 2025.07.28 11:52:58.194653 [ 17207 ] {c88d86d9-1bf7-43f8-8834-04c687184b57} PushingToViews: Failed to push block to view test_5.v1 (4ae2feef-b6fa-47ac-b20c-744da14b2a0a), Stack size too large. Stack address: 0x7fb7fddf0000, frame address: 0x7fb7fe1ef100, stack size: 4198144, maximum stack size: 8388608 2025.07.28 11:52:58.197902 [ 17207 ] {c88d86d9-1bf7-43f8-8834-04c687184b57} PushingToViews: Failed to push block to view test_5.v2 (7c22a887-3ed3-40f1-a092-d92463e4b87b), Stack size too large. Stack address: 0x7fb7fddf0000, frame address: 0x7fb7fe1ef100, stack size: 4198144, maximum stack size: 8388608 2025.07.28 11:52:58.205253 [ 17207 ] {c88d86d9-1bf7-43f8-8834-04c687184b57} PushingToViews: Failed to push block to view test_5.v1 (4ae2feef-b6fa-47ac-b20c-744da14b2a0a), Stack size too large. Stack address: 0x7fb7fddf0000, frame address: 0x7fb7fe1ef100, stack size: 4198144, maximum stack size: 8388608 2025.07.28 11:52:58.208788 [ 17207 ] {c88d86d9-1bf7-43f8-8834-04c687184b57} PushingToViews: Failed to push block to view test_5.v2 (7c22a887-3ed3-40f1-a092-d92463e4b87b), Stack size too large. Stack address: 0x7fb7fddf0000, frame address: 0x7fb7fe1ef100, stack size: 4198144, maximum stack size: 8388608 2025.07.28 11:52:58.211812 [ 17207 ] {c88d86d9-1bf7-43f8-8834-04c687184b57} PushingToViews: Failed to push block to view test_5.v1 (4ae2feef-b6fa-47ac-b20c-744da14b2a0a), Stack size too large. Stack address: 0x7fb7fddf0000, frame address: 0x7fb7fe1ef100, stack size: 4198144, maximum stack size: 8388608 2025.07.28 11:52:58.224193 [ 17207 ] {c88d86d9-1bf7-43f8-8834-04c687184b57} PushingToViews: Failed to push block to view test_5.v2 (7c22a887-3ed3-40f1-a092-d92463e4b87b), Stack size too large. Stack address: 0x7fb7fddf0000, frame address: 0x7fb7fe1ef100, stack size: 4198144, maximum stack size: 8388608 2025.07.28 11:52:58.228534 [ 17207 ] {c88d86d9-1bf7-43f8-8834-04c687184b57} PushingToViews: Failed to push block to view test_5.v1 (4ae2feef-b6fa-47ac-b20c-744da14b2a0a), Stack size too large. Stack address: 0x7fb7fddf0000, frame address: 0x7fb7fe1ef100, stack size: 4198144, maximum stack size: 8388608 2025.07.28 11:52:58.232909 [ 17207 ] {c88d86d9-1bf7-43f8-8834-04c687184b57} PushingToViews: Failed to push block to view test_5.v2 (7c22a887-3ed3-40f1-a092-d92463e4b87b), Stack size too large. Stack address: 0x7fb7fddf0000, frame address: 0x7fb7fe1ef100, stack size: 4198144, maximum stack size: 8388608 2025.07.28 11:52:58.235978 [ 17207 ] {c88d86d9-1bf7-43f8-8834-04c687184b57} PushingToViews: Failed to push block to view test_5.v1 (4ae2feef-b6fa-47ac-b20c-744da14b2a0a), Stack size too large. Stack address: 0x7fb7fddf0000, frame address: 0x7fb7fe1ef100, stack size: 4198144, maximum stack size: 8388608 2025.07.28 11:52:58.237525 [ 17207 ] {c88d86d9-1bf7-43f8-8834-04c687184b57} PushingToViews: Failed to push block to view test_5.v2 (7c22a887-3ed3-40f1-a092-d92463e4b87b), Stack size too large. Stack address: 0x7fb7fddf0000, frame address: 0x7fb7fe1ef100, stack size: 4198144, maximum stack size: 8388608 2025.07.28 11:52:58.240399 [ 17207 ] {c88d86d9-1bf7-43f8-8834-04c687184b57} PushingToViews: Failed to push block to view test_5.v1 (4ae2feef-b6fa-47ac-b20c-744da14b2a0a), Stack size too large. Stack address: 0x7fb7fddf0000, frame address: 0x7fb7fe1ef100, stack size: 4198144, maximum stack size: 8388608 2025.07.28 11:52:58.248131 [ 17207 ] {c88d86d9-1bf7-43f8-8834-04c687184b57} PushingToViews: Failed to push block to view test_5.v2 (7c22a887-3ed3-40f1-a092-d92463e4b87b), Stack size too large. Stack address: 0x7fb7fddf0000, frame address: 0x7fb7fe1ef100, stack size: 4198144, maximum stack size: 8388608 2025.07.28 11:52:58.264893 [ 17207 ] {c88d86d9-1bf7-43f8-8834-04c687184b57} PushingToViews: Failed to push block to view test_5.v1 (4ae2feef-b6fa-47ac-b20c-744da14b2a0a), Stack size too large. Stack address: 0x7fb7fddf0000, frame address: 0x7fb7fe1ef100, stack size: 4198144, maximum stack size: 8388608 2025.07.28 11:52:58.270246 [ 17207 ] {c88d86d9-1bf7-43f8-8834-04c687184b57} PushingToViews: Failed to push block to view test_5.v2 (7c22a887-3ed3-40f1-a092-d92463e4b87b), Stack size too large. Stack address: 0x7fb7fddf0000, frame address: 0x7fb7fe1ef100, stack size: 4198144, maximum stack size: 8388608 2025.07.28 11:52:58.276550 [ 17207 ] {c88d86d9-1bf7-43f8-8834-04c687184b57} PushingToViews: Failed to push block to view test_5.v1 (4ae2feef-b6fa-47ac-b20c-744da14b2a0a), Stack size too large. Stack address: 0x7fb7fddf0000, frame address: 0x7fb7fe1ef100, stack size: 4198144, maximum stack size: 8388608 2025.07.28 11:52:58.277636 [ 17207 ] {c88d86d9-1bf7-43f8-8834-04c687184b57} PushingToViews: Failed to push block to view test_5.v2 (7c22a887-3ed3-40f1-a092-d92463e4b87b), Stack size too large. Stack address: 0x7fb7fddf0000, frame address: 0x7fb7fe1ef100, stack size: 4198144, maximum stack size: 8388608 2025.07.28 11:52:58.278955 [ 17207 ] {c88d86d9-1bf7-43f8-8834-04c687184b57} PushingToViews: Failed to push block to view test_5.v1 (4ae2feef-b6fa-47ac-b20c-744da14b2a0a), Stack size too large. Stack address: 0x7fb7fddf0000, frame address: 0x7fb7fe1ef100, stack size: 4198144, maximum stack size: 8388608 2025.07.28 11:52:58.281901 [ 17207 ] {c88d86d9-1bf7-43f8-8834-04c687184b57} PushingToViews: Failed to push block to view test_5.v2 (7c22a887-3ed3-40f1-a092-d92463e4b87b), Stack size too large. Stack address: 0x7fb7fddf0000, frame address: 0x7fb7fe1ef100, stack size: 4198144, maximum stack size: 8388608 2025.07.28 11:52:58.287308 [ 17207 ] {c88d86d9-1bf7-43f8-8834-04c687184b57} PushingToViews: Failed to push block to view test_5.v1 (4ae2feef-b6fa-47ac-b20c-744da14b2a0a), Stack size too large. Stack address: 0x7fb7fddf0000, frame address: 0x7fb7fe1ef100, stack size: 4198144, maximum stack size: 8388608 2025.07.28 11:52:58.295352 [ 17207 ] {c88d86d9-1bf7-43f8-8834-04c687184b57} PushingToViews: Failed to push block to view test_5.v2 (7c22a887-3ed3-40f1-a092-d92463e4b87b), Stack size too large. Stack address: 0x7fb7fddf0000, frame address: 0x7fb7fe1ef100, stack size: 4198144, maximum stack size: 8388608 2025.07.28 11:52:58.299666 [ 17207 ] {c88d86d9-1bf7-43f8-8834-04c687184b57} PushingToViews: Failed to push block to view test_5.v1 (4ae2feef-b6fa-47ac-b20c-744da14b2a0a), Stack size too large. Stack address: 0x7fb7fddf0000, frame address: 0x7fb7fe1ef100, stack size: 4198144, maximum stack size: 8388608 2025.07.28 11:52:58.308049 [ 17207 ] {c88d86d9-1bf7-43f8-8834-04c687184b57} PushingToViews: Failed to push block to view test_5.v2 (7c22a887-3ed3-40f1-a092-d92463e4b87b), Stack size too large. Stack address: 0x7fb7fddf0000, frame address: 0x7fb7fe1ef100, stack size: 4198144, maximum stack size: 8388608 2025.07.28 11:52:58.310455 [ 17207 ] {c88d86d9-1bf7-43f8-8834-04c687184b57} PushingToViews: Failed to push block to view test_5.v1 (4ae2feef-b6fa-47ac-b20c-744da14b2a0a), Stack size too large. Stack address: 0x7fb7fddf0000, frame address: 0x7fb7fe1ef100, stack size: 4198144, maximum stack size: 8388608 2025.07.28 11:52:58.312005 [ 17207 ] {c88d86d9-1bf7-43f8-8834-04c687184b57} PushingToViews: Failed to push block to view test_5.v2 (7c22a887-3ed3-40f1-a092-d92463e4b87b), Stack size too large. Stack address: 0x7fb7fddf0000, frame address: 0x7fb7fe1ef100, stack size: 4198144, maximum stack size: 8388608 2025.07.28 11:52:58.313883 [ 17207 ] {c88d86d9-1bf7-43f8-8834-04c687184b57} PushingToViews: Failed to push block to view test_5.v1 (4ae2feef-b6fa-47ac-b20c-744da14b2a0a), Stack size too large. Stack address: 0x7fb7fddf0000, frame address: 0x7fb7fe1ef100, stack size: 4198144, maximum stack size: 8388608 2025.07.28 11:52:58.316184 [ 17207 ] {c88d86d9-1bf7-43f8-8834-04c687184b57} PushingToViews: Failed to push block to view test_5.v2 (7c22a887-3ed3-40f1-a092-d92463e4b87b), Stack size too large. Stack address: 0x7fb7fddf0000, frame address: 0x7fb7fe1ef100, stack size: 4198144, maximum stack size: 8388608 2025.07.28 11:52:58.317635 [ 17207 ] {c88d86d9-1bf7-43f8-8834-04c687184b57} PushingToViews: Failed to push block to view test_5.v1 (4ae2feef-b6fa-47ac-b20c-744da14b2a0a), Stack size too large. Stack address: 0x7fb7fddf0000, frame address: 0x7fb7fe1ef100, stack size: 4198144, maximum stack size: 8388608 2025.07.28 11:52:58.319857 [ 17207 ] {c88d86d9-1bf7-43f8-8834-04c687184b57} PushingToViews: Failed to push block to view test_5.v2 (7c22a887-3ed3-40f1-a092-d92463e4b87b), Stack size too large. Stack address: 0x7fb7fddf0000, frame address: 0x7fb7fe1ef100, stack size: 4198144, maximum stack size: 8388608 2025.07.28 11:52:58.324117 [ 17207 ] {c88d86d9-1bf7-43f8-8834-04c687184b57} PushingToViews: Failed to push block to view test_5.v1 (4ae2feef-b6fa-47ac-b20c-744da14b2a0a), Stack size too large. Stack address: 0x7fb7fddf0000, frame address: 0x7fb7fe1ef100, stack size: 4198144, maximum stack size: 8388608 2025.07.28 11:52:58.332183 [ 17207 ] {c88d86d9-1bf7-43f8-8834-04c687184b57} PushingToViews: Failed to push block to view test_5.v2 (7c22a887-3ed3-40f1-a092-d92463e4b87b), Stack size too large. Stack address: 0x7fb7fddf0000, frame address: 0x7fb7fe1ef100, stack size: 4198144, maximum stack size: 8388608 2025.07.28 11:52:58.333636 [ 17207 ] {c88d86d9-1bf7-43f8-8834-04c687184b57} PushingToViews: Failed to push block to view test_5.v1 (4ae2feef-b6fa-47ac-b20c-744da14b2a0a), Stack size too large. Stack address: 0x7fb7fddf0000, frame address: 0x7fb7fe1ef100, stack size: 4198144, maximum stack size: 8388608 2025.07.28 11:52:58.336129 [ 17207 ] {c88d86d9-1bf7-43f8-8834-04c687184b57} PushingToViews: Failed to push block to view test_5.v2 (7c22a887-3ed3-40f1-a092-d92463e4b87b), Stack size too large. Stack address: 0x7fb7fddf0000, frame address: 0x7fb7fe1ef100, stack size: 4198144, maximum stack size: 8388608 2025.07.28 11:52:58.337615 [ 17207 ] {c88d86d9-1bf7-43f8-8834-04c687184b57} PushingToViews: Failed to push block to view test_5.v1 (4ae2feef-b6fa-47ac-b20c-744da14b2a0a), Stack size too large. Stack address: 0x7fb7fddf0000, frame address: 0x7fb7fe1ef100, stack size: 4198144, maximum stack size: 8388608 2025.07.28 11:52:58.339217 [ 17207 ] {c88d86d9-1bf7-43f8-8834-04c687184b57} PushingToViews: Failed to push block to view test_5.v2 (7c22a887-3ed3-40f1-a092-d92463e4b87b), Stack size too large. Stack address: 0x7fb7fddf0000, frame address: 0x7fb7fe1ef100, stack size: 4198144, maximum stack size: 8388608 2025.07.28 11:52:58.347396 [ 17207 ] {c88d86d9-1bf7-43f8-8834-04c687184b57} PushingToViews: Failed to push block to view test_5.v1 (4ae2feef-b6fa-47ac-b20c-744da14b2a0a), Stack size too large. Stack address: 0x7fb7fddf0000, frame address: 0x7fb7fe1ef100, stack size: 4198144, maximum stack size: 8388608 2025.07.28 11:52:58.360300 [ 17207 ] {c88d86d9-1bf7-43f8-8834-04c687184b57} PushingToViews: Failed to push block to view test_5.v2 (7c22a887-3ed3-40f1-a092-d92463e4b87b), Stack size too large. Stack address: 0x7fb7fddf0000, frame address: 0x7fb7fe1ef100, stack size: 4198144, maximum stack size: 8388608 2025.07.28 11:52:58.361487 [ 17207 ] {c88d86d9-1bf7-43f8-8834-04c687184b57} PushingToViews: Failed to push block to view test_5.v1 (4ae2feef-b6fa-47ac-b20c-744da14b2a0a), Stack size too large. Stack address: 0x7fb7fddf0000, frame address: 0x7fb7fe1ef100, stack size: 4198144, maximum stack size: 8388608 2025.07.28 11:52:58.362977 [ 17207 ] {c88d86d9-1bf7-43f8-8834-04c687184b57} PushingToViews: Failed to push block to view test_5.v2 (7c22a887-3ed3-40f1-a092-d92463e4b87b), Stack size too large. Stack address: 0x7fb7fddf0000, frame address: 0x7fb7fe1ef100, stack size: 4198144, maximum stack size: 8388608 2025.07.28 11:52:58.365174 [ 17207 ] {c88d86d9-1bf7-43f8-8834-04c687184b57} PushingToViews: Failed to push block to view test_5.v1 (4ae2feef-b6fa-47ac-b20c-744da14b2a0a), Stack size too large. Stack address: 0x7fb7fddf0000, frame address: 0x7fb7fe1ef100, stack size: 4198144, maximum stack size: 8388608 2025.07.28 11:52:58.366156 [ 17207 ] {c88d86d9-1bf7-43f8-8834-04c687184b57} PushingToViews: Failed to push block to view test_5.v2 (7c22a887-3ed3-40f1-a092-d92463e4b87b), Stack size too large. Stack address: 0x7fb7fddf0000, frame address: 0x7fb7fe1ef100, stack size: 4198144, maximum stack size: 8388608 2025.07.28 11:52:58.367085 [ 17207 ] {c88d86d9-1bf7-43f8-8834-04c687184b57} PushingToViews: Failed to push block to view test_5.v1 (4ae2feef-b6fa-47ac-b20c-744da14b2a0a), Stack size too large. Stack address: 0x7fb7fddf0000, frame address: 0x7fb7fe1ef100, stack size: 4198144, maximum stack size: 8388608 2025.07.28 11:52:58.387927 [ 17207 ] {c88d86d9-1bf7-43f8-8834-04c687184b57} PushingToViews: Failed to push block to view test_5.v2 (7c22a887-3ed3-40f1-a092-d92463e4b87b), Stack size too large. Stack address: 0x7fb7fddf0000, frame address: 0x7fb7fe1ef100, stack size: 4198144, maximum stack size: 8388608 2025.07.28 11:52:58.395110 [ 17207 ] {c88d86d9-1bf7-43f8-8834-04c687184b57} PushingToViews: Failed to push block to view test_5.v1 (4ae2feef-b6fa-47ac-b20c-744da14b2a0a), Stack size too large. Stack address: 0x7fb7fddf0000, frame address: 0x7fb7fe1ef100, stack size: 4198144, maximum stack size: 8388608 2025.07.28 11:52:58.404785 [ 17207 ] {c88d86d9-1bf7-43f8-8834-04c687184b57} PushingToViews: Failed to push block to view test_5.v2 (7c22a887-3ed3-40f1-a092-d92463e4b87b), Stack size too large. Stack address: 0x7fb7fddf0000, frame address: 0x7fb7fe1ef100, stack size: 4198144, maximum stack size: 8388608 2025.07.28 11:52:58.414026 [ 17207 ] {c88d86d9-1bf7-43f8-8834-04c687184b57} PushingToViews: Failed to push block to view test_5.v1 (4ae2feef-b6fa-47ac-b20c-744da14b2a0a), Stack size too large. Stack address: 0x7fb7fddf0000, frame address: 0x7fb7fe1ef100, stack size: 4198144, maximum stack size: 8388608 2025.07.28 11:52:58.421640 [ 17207 ] {c88d86d9-1bf7-43f8-8834-04c687184b57} PushingToViews: Failed to push block to view test_5.v2 (7c22a887-3ed3-40f1-a092-d92463e4b87b), Stack size too large. Stack address: 0x7fb7fddf0000, frame address: 0x7fb7fe1ef100, stack size: 4198144, maximum stack size: 8388608 2025.07.28 11:52:58.422905 [ 17207 ] {c88d86d9-1bf7-43f8-8834-04c687184b57} PushingToViews: Failed to push block to view test_5.v1 (4ae2feef-b6fa-47ac-b20c-744da14b2a0a), Stack size too large. Stack address: 0x7fb7fddf0000, frame address: 0x7fb7fe1ef100, stack size: 4198144, maximum stack size: 8388608 2025.07.28 11:52:58.424593 [ 17207 ] {c88d86d9-1bf7-43f8-8834-04c687184b57} PushingToViews: Failed to push block to view test_5.v2 (7c22a887-3ed3-40f1-a092-d92463e4b87b), Stack size too large. Stack address: 0x7fb7fddf0000, frame address: 0x7fb7fe1ef100, stack size: 4198144, maximum stack size: 8388608 2025.07.28 11:52:58.425700 [ 17207 ] {c88d86d9-1bf7-43f8-8834-04c687184b57} PushingToViews: Failed to push block to view test_5.v1 (4ae2feef-b6fa-47ac-b20c-744da14b2a0a), Stack size too large. Stack address: 0x7fb7fddf0000, frame address: 0x7fb7fe1ef100, stack size: 4198144, maximum stack size: 8388608 2025.07.28 11:52:58.427720 [ 17207 ] {c88d86d9-1bf7-43f8-8834-04c687184b57} PushingToViews: Failed to push block to view test_5.v2 (7c22a887-3ed3-40f1-a092-d92463e4b87b), Stack size too large. Stack address: 0x7fb7fddf0000, frame address: 0x7fb7fe1ef100, stack size: 4198144, maximum stack size: 8388608 2025.07.28 11:52:58.429036 [ 17207 ] {c88d86d9-1bf7-43f8-8834-04c687184b57} PushingToViews: Failed to push block to view test_5.v1 (4ae2feef-b6fa-47ac-b20c-744da14b2a0a), Stack size too large. Stack address: 0x7fb7fddf0000, frame address: 0x7fb7fe1ef100, stack size: 4198144, maximum stack size: 8388608 2025.07.28 11:52:58.431185 [ 17207 ] {c88d86d9-1bf7-43f8-8834-04c687184b57} PushingToViews: Failed to push block to view test_5.v2 (7c22a887-3ed3-40f1-a092-d92463e4b87b), Stack size too large. Stack address: 0x7fb7fddf0000, frame address: 0x7fb7fe1ef100, stack size: 4198144, maximum stack size: 8388608 2025.07.28 11:52:58.432298 [ 17207 ] {c88d86d9-1bf7-43f8-8834-04c687184b57} PushingToViews: Failed to push block to view test_5.v1 (4ae2feef-b6fa-47ac-b20c-744da14b2a0a), Stack size too large. Stack address: 0x7fb7fddf0000, frame address: 0x7fb7fe1ef100, stack size: 4198144, maximum stack size: 8388608 2025.07.28 11:52:58.433234 [ 17207 ] {c88d86d9-1bf7-43f8-8834-04c687184b57} PushingToViews: Failed to push block to view test_5.v2 (7c22a887-3ed3-40f1-a092-d92463e4b87b), Stack size too large. Stack address: 0x7fb7fddf0000, frame address: 0x7fb7fe1ef100, stack size: 4198144, maximum stack size: 8388608 2025.07.28 11:52:58.435217 [ 17207 ] {c88d86d9-1bf7-43f8-8834-04c687184b57} PushingToViews: Failed to push block to view test_5.v1 (4ae2feef-b6fa-47ac-b20c-744da14b2a0a), Stack size too large. Stack address: 0x7fb7fddf0000, frame address: 0x7fb7fe1ef100, stack size: 4198144, maximum stack size: 8388608 2025.07.28 11:52:58.437053 [ 17207 ] {c88d86d9-1bf7-43f8-8834-04c687184b57} PushingToViews: Failed to push block to view test_5.v2 (7c22a887-3ed3-40f1-a092-d92463e4b87b), Stack size too large. Stack address: 0x7fb7fddf0000, frame address: 0x7fb7fe1ef100, stack size: 4198144, maximum stack size: 8388608 2025.07.28 11:52:58.438863 [ 17207 ] {c88d86d9-1bf7-43f8-8834-04c687184b57} PushingToViews: Failed to push block to view test_5.v1 (4ae2feef-b6fa-47ac-b20c-744da14b2a0a), Stack size too large. Stack address: 0x7fb7fddf0000, frame address: 0x7fb7fe1ef100, stack size: 4198144, maximum stack size: 8388608 2025.07.28 11:52:58.440683 [ 17207 ] {c88d86d9-1bf7-43f8-8834-04c687184b57} PushingToViews: Failed to push block to view test_5.v2 (7c22a887-3ed3-40f1-a092-d92463e4b87b), Stack size too large. Stack address: 0x7fb7fddf0000, frame address: 0x7fb7fe1ef100, stack size: 4198144, maximum stack size: 8388608 2025.07.28 11:52:58.442345 [ 17207 ] {c88d86d9-1bf7-43f8-8834-04c687184b57} PushingToViews: Failed to push block to view test_5.v1 (4ae2feef-b6fa-47ac-b20c-744da14b2a0a), Stack size too large. Stack address: 0x7fb7fddf0000, frame address: 0x7fb7fe1ef100, stack size: 4198144, maximum stack size: 8388608 2025.07.28 11:52:58.449339 [ 17207 ] {c88d86d9-1bf7-43f8-8834-04c687184b57} PushingToViews: Failed to push block to view test_5.v2 (7c22a887-3ed3-40f1-a092-d92463e4b87b), Stack size too large. Stack address: 0x7fb7fddf0000, frame address: 0x7fb7fe1ef100, stack size: 4198144, maximum stack size: 8388608 2025.07.28 11:52:58.452051 [ 17207 ] {c88d86d9-1bf7-43f8-8834-04c687184b57} PushingToViews: Failed to push block to view test_5.v1 (4ae2feef-b6fa-47ac-b20c-744da14b2a0a), Stack size too large. Stack address: 0x7fb7fddf0000, frame address: 0x7fb7fe1ef100, stack size: 4198144, maximum stack size: 8388608 2025.07.28 11:52:58.456121 [ 17207 ] {c88d86d9-1bf7-43f8-8834-04c687184b57} PushingToViews: Failed to push block to view test_5.v2 (7c22a887-3ed3-40f1-a092-d92463e4b87b), Stack size too large. Stack address: 0x7fb7fddf0000, frame address: 0x7fb7fe1ef100, stack size: 4198144, maximum stack size: 8388608 2025.07.28 11:52:58.459729 [ 17207 ] {c88d86d9-1bf7-43f8-8834-04c687184b57} PushingToViews: Failed to push block to view test_5.v1 (4ae2feef-b6fa-47ac-b20c-744da14b2a0a), Stack size too large. Stack address: 0x7fb7fddf0000, frame address: 0x7fb7fe1ef100, stack size: 4198144, maximum stack size: 8388608 2025.07.28 11:52:58.461196 [ 17207 ] {c88d86d9-1bf7-43f8-8834-04c687184b57} PushingToViews: Failed to push block to view test_5.v2 (7c22a887-3ed3-40f1-a092-d92463e4b87b), Stack size too large. Stack address: 0x7fb7fddf0000, frame address: 0x7fb7fe1ef100, stack size: 4198144, maximum stack size: 8388608 2025.07.28 11:52:58.462476 [ 17207 ] {c88d86d9-1bf7-43f8-8834-04c687184b57} PushingToViews: Failed to push block to view test_5.v1 (4ae2feef-b6fa-47ac-b20c-744da14b2a0a), Stack size too large. Stack address: 0x7fb7fddf0000, frame address: 0x7fb7fe1ef100, stack size: 4198144, maximum stack size: 8388608 2025.07.28 11:52:58.464328 [ 17207 ] {c88d86d9-1bf7-43f8-8834-04c687184b57} PushingToViews: Failed to push block to view test_5.v2 (7c22a887-3ed3-40f1-a092-d92463e4b87b), Stack size too large. Stack address: 0x7fb7fddf0000, frame address: 0x7fb7fe1ef100, stack size: 4198144, maximum stack size: 8388608 2025.07.28 11:52:58.465369 [ 17207 ] {c88d86d9-1bf7-43f8-8834-04c687184b57} PushingToViews: Failed to push block to view test_5.v1 (4ae2feef-b6fa-47ac-b20c-744da14b2a0a), Stack size too large. Stack address: 0x7fb7fddf0000, frame address: 0x7fb7fe1ef100, stack size: 4198144, maximum stack size: 8388608 2025.07.28 11:52:58.467980 [ 17207 ] {c88d86d9-1bf7-43f8-8834-04c687184b57} PushingToViews: Failed to push block to view test_5.v2 (7c22a887-3ed3-40f1-a092-d92463e4b87b), Stack size too large. Stack address: 0x7fb7fddf0000, frame address: 0x7fb7fe1ef100, stack size: 4198144, maximum stack size: 8388608 2025.07.28 11:52:58.499850 [ 17207 ] {c88d86d9-1bf7-43f8-8834-04c687184b57} PushingToViews: Failed to push block to view test_5.v1 (4ae2feef-b6fa-47ac-b20c-744da14b2a0a), Stack size too large. Stack address: 0x7fb7fddf0000, frame address: 0x7fb7fe1ef100, stack size: 4198144, maximum stack size: 8388608 2025.07.28 11:52:58.500979 [ 17207 ] {c88d86d9-1bf7-43f8-8834-04c687184b57} PushingToViews: Failed to push block to view test_5.v2 (7c22a887-3ed3-40f1-a092-d92463e4b87b), Stack size too large. Stack address: 0x7fb7fddf0000, frame address: 0x7fb7fe1ef100, stack size: 4198144, maximum stack size: 8388608 2025.07.28 11:52:58.507228 [ 17207 ] {c88d86d9-1bf7-43f8-8834-04c687184b57} PushingToViews: Failed to push block to view test_5.v1 (4ae2feef-b6fa-47ac-b20c-744da14b2a0a), Stack size too large. Stack address: 0x7fb7fddf0000, frame address: 0x7fb7fe1ef100, stack size: 4198144, maximum stack size: 8388608 2025.07.28 11:52:58.508526 [ 17207 ] {c88d86d9-1bf7-43f8-8834-04c687184b57} PushingToViews: Failed to push block to view test_5.v2 (7c22a887-3ed3-40f1-a092-d92463e4b87b), Stack size too large. Stack address: 0x7fb7fddf0000, frame address: 0x7fb7fe1ef100, stack size: 4198144, maximum stack size: 8388608 2025.07.28 11:52:58.509273 [ 17207 ] {c88d86d9-1bf7-43f8-8834-04c687184b57} PushingToViews: Failed to push block to view test_5.v1 (4ae2feef-b6fa-47ac-b20c-744da14b2a0a), Stack size too large. Stack address: 0x7fb7fddf0000, frame address: 0x7fb7fe1ef100, stack size: 4198144, maximum stack size: 8388608 2025.07.28 11:52:58.545386 [ 17207 ] {c88d86d9-1bf7-43f8-8834-04c687184b57} PushingToViews: Failed to push block to view test_5.v2 (7c22a887-3ed3-40f1-a092-d92463e4b87b), Stack size too large. Stack address: 0x7fb7fddf0000, frame address: 0x7fb7fe1ef100, stack size: 4198144, maximum stack size: 8388608 2025.07.28 11:52:58.546348 [ 17207 ] {c88d86d9-1bf7-43f8-8834-04c687184b57} PushingToViews: Failed to push block to view test_5.v1 (4ae2feef-b6fa-47ac-b20c-744da14b2a0a), Stack size too large. Stack address: 0x7fb7fddf0000, frame address: 0x7fb7fe1ef100, stack size: 4198144, maximum stack size: 8388608 2025.07.28 11:52:58.547306 [ 17207 ] {c88d86d9-1bf7-43f8-8834-04c687184b57} PushingToViews: Failed to push block to view test_5.v2 (7c22a887-3ed3-40f1-a092-d92463e4b87b), Stack size too large. Stack address: 0x7fb7fddf0000, frame address: 0x7fb7fe1ef100, stack size: 4198144, maximum stack size: 8388608 2025.07.28 11:52:58.548533 [ 17207 ] {c88d86d9-1bf7-43f8-8834-04c687184b57} PushingToViews: Failed to push block to view test_5.v1 (4ae2feef-b6fa-47ac-b20c-744da14b2a0a), Stack size too large. Stack address: 0x7fb7fddf0000, frame address: 0x7fb7fe1ef100, stack size: 4198144, maximum stack size: 8388608 2025.07.28 11:52:58.550165 [ 17207 ] {c88d86d9-1bf7-43f8-8834-04c687184b57} PushingToViews: Failed to push block to view test_5.v2 (7c22a887-3ed3-40f1-a092-d92463e4b87b), Stack size too large. Stack address: 0x7fb7fddf0000, frame address: 0x7fb7fe1ef100, stack size: 4198144, maximum stack size: 8388608 2025.07.28 11:52:58.551179 [ 17207 ] {c88d86d9-1bf7-43f8-8834-04c687184b57} PushingToViews: Failed to push block to view test_5.v1 (4ae2feef-b6fa-47ac-b20c-744da14b2a0a), Stack size too large. Stack address: 0x7fb7fddf0000, frame address: 0x7fb7fe1ef100, stack size: 4198144, maximum stack size: 8388608 2025.07.28 11:52:58.552212 [ 17207 ] {c88d86d9-1bf7-43f8-8834-04c687184b57} PushingToViews: Failed to push block to view test_5.v2 (7c22a887-3ed3-40f1-a092-d92463e4b87b), Stack size too large. Stack address: 0x7fb7fddf0000, frame address: 0x7fb7fe1ef100, stack size: 4198144, maximum stack size: 8388608 2025.07.28 11:52:58.555998 [ 17207 ] {c88d86d9-1bf7-43f8-8834-04c687184b57} PushingToViews: Failed to push block to view test_5.v1 (4ae2feef-b6fa-47ac-b20c-744da14b2a0a), Stack size too large. Stack address: 0x7fb7fddf0000, frame address: 0x7fb7fe1ef100, stack size: 4198144, maximum stack size: 8388608 2025.07.28 11:52:58.557394 [ 17207 ] {c88d86d9-1bf7-43f8-8834-04c687184b57} PushingToViews: Failed to push block to view test_5.v2 (7c22a887-3ed3-40f1-a092-d92463e4b87b), Stack size too large. Stack address: 0x7fb7fddf0000, frame address: 0x7fb7fe1ef100, stack size: 4198144, maximum stack size: 8388608 2025.07.28 11:52:58.558870 [ 17207 ] {c88d86d9-1bf7-43f8-8834-04c687184b57} PushingToViews: Failed to push block to view test_5.v1 (4ae2feef-b6fa-47ac-b20c-744da14b2a0a), Stack size too large. Stack address: 0x7fb7fddf0000, frame address: 0x7fb7fe1ef100, stack size: 4198144, maximum stack size: 8388608 2025.07.28 11:52:58.560436 [ 17207 ] {c88d86d9-1bf7-43f8-8834-04c687184b57} PushingToViews: Failed to push block to view test_5.v2 (7c22a887-3ed3-40f1-a092-d92463e4b87b), Stack size too large. Stack address: 0x7fb7fddf0000, frame address: 0x7fb7fe1ef100, stack size: 4198144, maximum stack size: 8388608 2025.07.28 11:52:58.561420 [ 17207 ] {c88d86d9-1bf7-43f8-8834-04c687184b57} PushingToViews: Failed to push block to view test_5.v1 (4ae2feef-b6fa-47ac-b20c-744da14b2a0a), Stack size too large. Stack address: 0x7fb7fddf0000, frame address: 0x7fb7fe1ef100, stack size: 4198144, maximum stack size: 8388608 2025.07.28 11:52:58.562265 [ 17207 ] {c88d86d9-1bf7-43f8-8834-04c687184b57} PushingToViews: Failed to push block to view test_5.v2 (7c22a887-3ed3-40f1-a092-d92463e4b87b), Stack size too large. Stack address: 0x7fb7fddf0000, frame address: 0x7fb7fe1ef100, stack size: 4198144, maximum stack size: 8388608 2025.07.28 11:52:58.563473 [ 17207 ] {c88d86d9-1bf7-43f8-8834-04c687184b57} PushingToViews: Failed to push block to view test_5.v1 (4ae2feef-b6fa-47ac-b20c-744da14b2a0a), Stack size too large. Stack address: 0x7fb7fddf0000, frame address: 0x7fb7fe1ef100, stack size: 4198144, maximum stack size: 8388608 2025.07.28 11:52:58.594372 [ 17207 ] {c88d86d9-1bf7-43f8-8834-04c687184b57} PushingToViews: Failed to push block to view test_5.v2 (7c22a887-3ed3-40f1-a092-d92463e4b87b), Stack size too large. Stack address: 0x7fb7fddf0000, frame address: 0x7fb7fe1ef100, stack size: 4198144, maximum stack size: 8388608 2025.07.28 11:52:58.595133 [ 17207 ] {c88d86d9-1bf7-43f8-8834-04c687184b57} PushingToViews: Failed to push block to view test_5.v1 (4ae2feef-b6fa-47ac-b20c-744da14b2a0a), Stack size too large. Stack address: 0x7fb7fddf0000, frame address: 0x7fb7fe1ef100, stack size: 4198144, maximum stack size: 8388608 2025.07.28 11:52:58.596008 [ 17207 ] {c88d86d9-1bf7-43f8-8834-04c687184b57} PushingToViews: Failed to push block to view test_5.v2 (7c22a887-3ed3-40f1-a092-d92463e4b87b), Stack size too large. Stack address: 0x7fb7fddf0000, frame address: 0x7fb7fe1ef100, stack size: 4198144, maximum stack size: 8388608 2025.07.28 11:52:58.597772 [ 17207 ] {c88d86d9-1bf7-43f8-8834-04c687184b57} PushingToViews: Failed to push block to view test_5.v1 (4ae2feef-b6fa-47ac-b20c-744da14b2a0a), Stack size too large. Stack address: 0x7fb7fddf0000, frame address: 0x7fb7fe1ef100, stack size: 4198144, maximum stack size: 8388608 2025.07.28 11:52:58.599451 [ 17207 ] {c88d86d9-1bf7-43f8-8834-04c687184b57} PushingToViews: Failed to push block to view test_5.v2 (7c22a887-3ed3-40f1-a092-d92463e4b87b), Stack size too large. Stack address: 0x7fb7fddf0000, frame address: 0x7fb7fe1ef100, stack size: 4198144, maximum stack size: 8388608 2025.07.28 11:52:58.599668 [ 3287 ] {d679f3a7-c4ed-40ed-8ccb-2032b15c4f0e} executeQuery: Code: 47. DB::Exception: Unknown expression or function identifier `x` in scope x = 1. Maybe you meant: ['t']. (UNKNOWN_IDENTIFIER) (version 25.3.6.10636.altinitytest (altinity build)) (from [::1]:47590) (comment: 02232_functions_to_subcolumns_alias.sql) (query 4, line 6) (in query: SELECT count(id) AS cnt FROM t_functions_to_subcolumns_alias FORMAT TSVWithNames;), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.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&&) @ 0x000000001404b3b9 4. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3771: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000001401b849 5. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3980: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000014018e31 6. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:2925: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000001402fcbd 7. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3838: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000014019a9e 8. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:209: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000001401270e 9. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000014011fce 10. /build/src/Planner/Utils.cpp:458: DB::buildFilterInfo(std::shared_ptr, std::shared_ptr const&, std::shared_ptr&, std::unordered_set, std::equal_to, std::allocator>) @ 0x0000000013fe8bcf 11. /build/src/Planner/PlannerJoinTree.cpp:535: DB::(anonymous namespace)::buildQueryPlanForTableExpression(std::shared_ptr, std::shared_ptr const&, DB::SelectQueryInfo const&, DB::SelectQueryOptions const&, std::shared_ptr&, bool, bool) @ 0x00000000149956d3 12. /build/src/Planner/PlannerJoinTree.cpp:2252: DB::buildJoinTreeQueryPlan(std::shared_ptr const&, DB::SelectQueryInfo const&, DB::SelectQueryOptions&, std::unordered_set, std::equal_to, std::allocator> const&, std::shared_ptr&) @ 0x000000001498e109 13. /build/src/Planner/Planner.cpp:1553: DB::Planner::buildPlanForQueryNode() @ 0x0000000014979dae 14. /build/src/Planner/Planner.cpp:1308: DB::Planner::buildQueryPlanIfNeeded() @ 0x000000001497685c 15. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:255: DB::InterpreterSelectQueryAnalyzer::getQueryPlan() @ 0x000000001497476d 16. /build/src/Interpreters/executeQuery.cpp:1405: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88806 17. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 18. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 19. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 20. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 21. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 22. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 23. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 24. ? @ 0x00007fbc6213eac3 25. ? @ 0x00007fbc621d0850 2025.07.28 11:52:58.600299 [ 17207 ] {c88d86d9-1bf7-43f8-8834-04c687184b57} PushingToViews: Failed to push block to view test_5.v1 (4ae2feef-b6fa-47ac-b20c-744da14b2a0a), Stack size too large. Stack address: 0x7fb7fddf0000, frame address: 0x7fb7fe1ef100, stack size: 4198144, maximum stack size: 8388608 2025.07.28 11:52:58.601904 [ 17207 ] {c88d86d9-1bf7-43f8-8834-04c687184b57} PushingToViews: Failed to push block to view test_5.v2 (7c22a887-3ed3-40f1-a092-d92463e4b87b), Stack size too large. Stack address: 0x7fb7fddf0000, frame address: 0x7fb7fe1ef100, stack size: 4198144, maximum stack size: 8388608 2025.07.28 11:52:58.602810 [ 3287 ] {} TCPHandler: Code: 47. DB::Exception: Unknown expression or function identifier `x` in scope x = 1. Maybe you meant: ['t']. (UNKNOWN_IDENTIFIER), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.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&&) @ 0x000000001404b3b9 4. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3771: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000001401b849 5. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3980: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000014018e31 6. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:2925: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000001402fcbd 7. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3838: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000014019a9e 8. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:209: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000001401270e 9. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000014011fce 10. /build/src/Planner/Utils.cpp:458: DB::buildFilterInfo(std::shared_ptr, std::shared_ptr const&, std::shared_ptr&, std::unordered_set, std::equal_to, std::allocator>) @ 0x0000000013fe8bcf 11. /build/src/Planner/PlannerJoinTree.cpp:535: DB::(anonymous namespace)::buildQueryPlanForTableExpression(std::shared_ptr, std::shared_ptr const&, DB::SelectQueryInfo const&, DB::SelectQueryOptions const&, std::shared_ptr&, bool, bool) @ 0x00000000149956d3 12. /build/src/Planner/PlannerJoinTree.cpp:2252: DB::buildJoinTreeQueryPlan(std::shared_ptr const&, DB::SelectQueryInfo const&, DB::SelectQueryOptions&, std::unordered_set, std::equal_to, std::allocator> const&, std::shared_ptr&) @ 0x000000001498e109 13. /build/src/Planner/Planner.cpp:1553: DB::Planner::buildPlanForQueryNode() @ 0x0000000014979dae 14. /build/src/Planner/Planner.cpp:1308: DB::Planner::buildQueryPlanIfNeeded() @ 0x000000001497685c 15. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:255: DB::InterpreterSelectQueryAnalyzer::getQueryPlan() @ 0x000000001497476d 16. /build/src/Interpreters/executeQuery.cpp:1405: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88806 17. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 18. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 19. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 20. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 21. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 22. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 23. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 24. ? @ 0x00007fbc6213eac3 25. ? @ 0x00007fbc621d0850 2025.07.28 11:52:58.605665 [ 17207 ] {c88d86d9-1bf7-43f8-8834-04c687184b57} PushingToViews: Failed to push block to view test_5.v1 (4ae2feef-b6fa-47ac-b20c-744da14b2a0a), Stack size too large. Stack address: 0x7fb7fddf0000, frame address: 0x7fb7fe1ef100, stack size: 4198144, maximum stack size: 8388608 2025.07.28 11:52:58.612814 [ 17207 ] {c88d86d9-1bf7-43f8-8834-04c687184b57} PushingToViews: Failed to push block to view test_5.v2 (7c22a887-3ed3-40f1-a092-d92463e4b87b), Stack size too large. Stack address: 0x7fb7fddf0000, frame address: 0x7fb7fe1ef100, stack size: 4198144, maximum stack size: 8388608 2025.07.28 11:52:58.613936 [ 17207 ] {c88d86d9-1bf7-43f8-8834-04c687184b57} PushingToViews: Failed to push block to view test_5.v1 (4ae2feef-b6fa-47ac-b20c-744da14b2a0a), Stack size too large. Stack address: 0x7fb7fddf0000, frame address: 0x7fb7fe1ef100, stack size: 4198144, maximum stack size: 8388608 2025.07.28 11:52:58.616002 [ 17207 ] {c88d86d9-1bf7-43f8-8834-04c687184b57} PushingToViews: Failed to push block to view test_5.v2 (7c22a887-3ed3-40f1-a092-d92463e4b87b), Stack size too large. Stack address: 0x7fb7fddf0000, frame address: 0x7fb7fe1ef100, stack size: 4198144, maximum stack size: 8388608 2025.07.28 11:52:58.617705 [ 17207 ] {c88d86d9-1bf7-43f8-8834-04c687184b57} PushingToViews: Failed to push block to view test_5.v1 (4ae2feef-b6fa-47ac-b20c-744da14b2a0a), Stack size too large. Stack address: 0x7fb7fddf0000, frame address: 0x7fb7fe1ef100, stack size: 4198144, maximum stack size: 8388608 2025.07.28 11:52:58.618439 [ 17207 ] {c88d86d9-1bf7-43f8-8834-04c687184b57} PushingToViews: Failed to push block to view test_5.v2 (7c22a887-3ed3-40f1-a092-d92463e4b87b), Stack size too large. Stack address: 0x7fb7fddf0000, frame address: 0x7fb7fe1ef100, stack size: 4198144, maximum stack size: 8388608 2025.07.28 11:52:58.620037 [ 17207 ] {c88d86d9-1bf7-43f8-8834-04c687184b57} PushingToViews: Failed to push block to view test_5.v1 (4ae2feef-b6fa-47ac-b20c-744da14b2a0a), Stack size too large. Stack address: 0x7fb7fddf0000, frame address: 0x7fb7fe1ef100, stack size: 4198144, maximum stack size: 8388608 2025.07.28 11:52:58.622158 [ 17207 ] {c88d86d9-1bf7-43f8-8834-04c687184b57} PushingToViews: Failed to push block to view test_5.v2 (7c22a887-3ed3-40f1-a092-d92463e4b87b), Stack size too large. Stack address: 0x7fb7fddf0000, frame address: 0x7fb7fe1ef100, stack size: 4198144, maximum stack size: 8388608 2025.07.28 11:52:58.625865 [ 17207 ] {c88d86d9-1bf7-43f8-8834-04c687184b57} PushingToViews: Failed to push block to view test_5.v1 (4ae2feef-b6fa-47ac-b20c-744da14b2a0a), Stack size too large. Stack address: 0x7fb7fddf0000, frame address: 0x7fb7fe1ef100, stack size: 4198144, maximum stack size: 8388608 2025.07.28 11:52:58.632433 [ 17207 ] {c88d86d9-1bf7-43f8-8834-04c687184b57} PushingToViews: Failed to push block to view test_5.v2 (7c22a887-3ed3-40f1-a092-d92463e4b87b), Stack size too large. Stack address: 0x7fb7fddf0000, frame address: 0x7fb7fe1ef100, stack size: 4198144, maximum stack size: 8388608 2025.07.28 11:52:58.633884 [ 17207 ] {c88d86d9-1bf7-43f8-8834-04c687184b57} PushingToViews: Failed to push block to view test_5.v1 (4ae2feef-b6fa-47ac-b20c-744da14b2a0a), Stack size too large. Stack address: 0x7fb7fddf0000, frame address: 0x7fb7fe1ef100, stack size: 4198144, maximum stack size: 8388608 2025.07.28 11:52:58.634544 [ 17207 ] {c88d86d9-1bf7-43f8-8834-04c687184b57} PushingToViews: Failed to push block to view test_5.v2 (7c22a887-3ed3-40f1-a092-d92463e4b87b), Stack size too large. Stack address: 0x7fb7fddf0000, frame address: 0x7fb7fe1ef100, stack size: 4198144, maximum stack size: 8388608 2025.07.28 11:52:58.635477 [ 17207 ] {c88d86d9-1bf7-43f8-8834-04c687184b57} PushingToViews: Failed to push block to view test_5.v1 (4ae2feef-b6fa-47ac-b20c-744da14b2a0a), Stack size too large. Stack address: 0x7fb7fddf0000, frame address: 0x7fb7fe1ef100, stack size: 4198144, maximum stack size: 8388608 2025.07.28 11:52:58.637385 [ 17207 ] {c88d86d9-1bf7-43f8-8834-04c687184b57} PushingToViews: Failed to push block to view test_5.v2 (7c22a887-3ed3-40f1-a092-d92463e4b87b), Stack size too large. Stack address: 0x7fb7fddf0000, frame address: 0x7fb7fe1ef100, stack size: 4198144, maximum stack size: 8388608 2025.07.28 11:52:58.638043 [ 17207 ] {c88d86d9-1bf7-43f8-8834-04c687184b57} PushingToViews: Failed to push block to view test_5.v1 (4ae2feef-b6fa-47ac-b20c-744da14b2a0a), Stack size too large. Stack address: 0x7fb7fddf0000, frame address: 0x7fb7fe1ef100, stack size: 4198144, maximum stack size: 8388608 2025.07.28 11:52:58.639363 [ 17207 ] {c88d86d9-1bf7-43f8-8834-04c687184b57} PushingToViews: Failed to push block to view test_5.v2 (7c22a887-3ed3-40f1-a092-d92463e4b87b), Stack size too large. Stack address: 0x7fb7fddf0000, frame address: 0x7fb7fe1ef100, stack size: 4198144, maximum stack size: 8388608 2025.07.28 11:52:58.640321 [ 17207 ] {c88d86d9-1bf7-43f8-8834-04c687184b57} PushingToViews: Failed to push block to view test_5.v1 (4ae2feef-b6fa-47ac-b20c-744da14b2a0a), Stack size too large. Stack address: 0x7fb7fddf0000, frame address: 0x7fb7fe1ef100, stack size: 4198144, maximum stack size: 8388608 2025.07.28 11:52:58.641490 [ 17207 ] {c88d86d9-1bf7-43f8-8834-04c687184b57} PushingToViews: Failed to push block to view test_5.v2 (7c22a887-3ed3-40f1-a092-d92463e4b87b), Stack size too large. Stack address: 0x7fb7fddf0000, frame address: 0x7fb7fe1ef100, stack size: 4198144, maximum stack size: 8388608 2025.07.28 11:52:58.643804 [ 17207 ] {c88d86d9-1bf7-43f8-8834-04c687184b57} PushingToViews: Failed to push block to view test_5.v1 (4ae2feef-b6fa-47ac-b20c-744da14b2a0a), Stack size too large. Stack address: 0x7fb7fddf0000, frame address: 0x7fb7fe1ef100, stack size: 4198144, maximum stack size: 8388608 2025.07.28 11:52:58.653047 [ 17207 ] {c88d86d9-1bf7-43f8-8834-04c687184b57} PushingToViews: Failed to push block to view test_5.v2 (7c22a887-3ed3-40f1-a092-d92463e4b87b), Stack size too large. Stack address: 0x7fb7fddf0000, frame address: 0x7fb7fe1ef100, stack size: 4198144, maximum stack size: 8388608 2025.07.28 11:52:58.654306 [ 17207 ] {c88d86d9-1bf7-43f8-8834-04c687184b57} PushingToViews: Failed to push block to view test_5.v1 (4ae2feef-b6fa-47ac-b20c-744da14b2a0a), Stack size too large. Stack address: 0x7fb7fddf0000, frame address: 0x7fb7fe1ef100, stack size: 4198144, maximum stack size: 8388608 2025.07.28 11:52:58.668401 [ 17207 ] {c88d86d9-1bf7-43f8-8834-04c687184b57} PushingToViews: Failed to push block to view test_5.v2 (7c22a887-3ed3-40f1-a092-d92463e4b87b), Stack size too large. Stack address: 0x7fb7fddf0000, frame address: 0x7fb7fe1ef100, stack size: 4198144, maximum stack size: 8388608 2025.07.28 11:52:58.669867 [ 17207 ] {c88d86d9-1bf7-43f8-8834-04c687184b57} PushingToViews: Failed to push block to view test_5.v1 (4ae2feef-b6fa-47ac-b20c-744da14b2a0a), Stack size too large. Stack address: 0x7fb7fddf0000, frame address: 0x7fb7fe1ef100, stack size: 4198144, maximum stack size: 8388608 2025.07.28 11:52:58.672983 [ 17207 ] {c88d86d9-1bf7-43f8-8834-04c687184b57} PushingToViews: Failed to push block to view test_5.v2 (7c22a887-3ed3-40f1-a092-d92463e4b87b), Stack size too large. Stack address: 0x7fb7fddf0000, frame address: 0x7fb7fe1ef100, stack size: 4198144, maximum stack size: 8388608 2025.07.28 11:52:58.676065 [ 17207 ] {c88d86d9-1bf7-43f8-8834-04c687184b57} PushingToViews: Failed to push block to view test_5.v1 (4ae2feef-b6fa-47ac-b20c-744da14b2a0a), Stack size too large. Stack address: 0x7fb7fddf0000, frame address: 0x7fb7fe1ef100, stack size: 4198144, maximum stack size: 8388608 2025.07.28 11:52:58.682560 [ 17207 ] {c88d86d9-1bf7-43f8-8834-04c687184b57} PushingToViews: Failed to push block to view test_5.v2 (7c22a887-3ed3-40f1-a092-d92463e4b87b), Stack size too large. Stack address: 0x7fb7fddf0000, frame address: 0x7fb7fe1ef100, stack size: 4198144, maximum stack size: 8388608 2025.07.28 11:52:58.683753 [ 17207 ] {c88d86d9-1bf7-43f8-8834-04c687184b57} PushingToViews: Failed to push block to view test_5.v1 (4ae2feef-b6fa-47ac-b20c-744da14b2a0a), Stack size too large. Stack address: 0x7fb7fddf0000, frame address: 0x7fb7fe1ef100, stack size: 4198144, maximum stack size: 8388608 2025.07.28 11:52:58.699148 [ 17207 ] {c88d86d9-1bf7-43f8-8834-04c687184b57} PushingToViews: Failed to push block to view test_5.v2 (7c22a887-3ed3-40f1-a092-d92463e4b87b), Stack size too large. Stack address: 0x7fb7fddf0000, frame address: 0x7fb7fe1ef100, stack size: 4198144, maximum stack size: 8388608 2025.07.28 11:52:58.701650 [ 17207 ] {c88d86d9-1bf7-43f8-8834-04c687184b57} PushingToViews: Failed to push block to view test_5.v1 (4ae2feef-b6fa-47ac-b20c-744da14b2a0a), Stack size too large. Stack address: 0x7fb7fddf0000, frame address: 0x7fb7fe1ef100, stack size: 4198144, maximum stack size: 8388608 2025.07.28 11:52:58.704135 [ 17207 ] {c88d86d9-1bf7-43f8-8834-04c687184b57} PushingToViews: Failed to push block to view test_5.v2 (7c22a887-3ed3-40f1-a092-d92463e4b87b), Stack size too large. Stack address: 0x7fb7fddf0000, frame address: 0x7fb7fe1ef100, stack size: 4198144, maximum stack size: 8388608 2025.07.28 11:52:58.708340 [ 17207 ] {c88d86d9-1bf7-43f8-8834-04c687184b57} PushingToViews: Failed to push block to view test_5.v1 (4ae2feef-b6fa-47ac-b20c-744da14b2a0a), Stack size too large. Stack address: 0x7fb7fddf0000, frame address: 0x7fb7fe1ef100, stack size: 4198144, maximum stack size: 8388608 2025.07.28 11:52:58.714549 [ 17207 ] {c88d86d9-1bf7-43f8-8834-04c687184b57} PushingToViews: Failed to push block to view test_5.v2 (7c22a887-3ed3-40f1-a092-d92463e4b87b), Stack size too large. Stack address: 0x7fb7fddf0000, frame address: 0x7fb7fe1ef100, stack size: 4198144, maximum stack size: 8388608 2025.07.28 11:52:58.715771 [ 17207 ] {c88d86d9-1bf7-43f8-8834-04c687184b57} PushingToViews: Failed to push block to view test_5.v1 (4ae2feef-b6fa-47ac-b20c-744da14b2a0a), Stack size too large. Stack address: 0x7fb7fddf0000, frame address: 0x7fb7fe1ef100, stack size: 4198144, maximum stack size: 8388608 2025.07.28 11:52:58.780823 [ 17207 ] {c88d86d9-1bf7-43f8-8834-04c687184b57} PushingToViews: Failed to push block to view test_5.v2 (7c22a887-3ed3-40f1-a092-d92463e4b87b), Stack size too large. Stack address: 0x7fb7fddf0000, frame address: 0x7fb7fe1ef100, stack size: 4198144, maximum stack size: 8388608 2025.07.28 11:52:58.781990 [ 17207 ] {c88d86d9-1bf7-43f8-8834-04c687184b57} PushingToViews: Failed to push block to view test_5.v1 (4ae2feef-b6fa-47ac-b20c-744da14b2a0a), Stack size too large. Stack address: 0x7fb7fddf0000, frame address: 0x7fb7fe1ef100, stack size: 4198144, maximum stack size: 8388608 2025.07.28 11:52:58.783648 [ 17207 ] {c88d86d9-1bf7-43f8-8834-04c687184b57} PushingToViews: Failed to push block to view test_5.v2 (7c22a887-3ed3-40f1-a092-d92463e4b87b), Stack size too large. Stack address: 0x7fb7fddf0000, frame address: 0x7fb7fe1ef100, stack size: 4198144, maximum stack size: 8388608 2025.07.28 11:52:58.791537 [ 17207 ] {c88d86d9-1bf7-43f8-8834-04c687184b57} PushingToViews: Failed to push block to view test_5.v1 (4ae2feef-b6fa-47ac-b20c-744da14b2a0a), Stack size too large. Stack address: 0x7fb7fddf0000, frame address: 0x7fb7fe1ef100, stack size: 4198144, maximum stack size: 8388608 2025.07.28 11:52:58.792643 [ 17207 ] {c88d86d9-1bf7-43f8-8834-04c687184b57} PushingToViews: Failed to push block to view test_5.v2 (7c22a887-3ed3-40f1-a092-d92463e4b87b), Stack size too large. Stack address: 0x7fb7fddf0000, frame address: 0x7fb7fe1ef100, stack size: 4198144, maximum stack size: 8388608 2025.07.28 11:52:58.794651 [ 17207 ] {c88d86d9-1bf7-43f8-8834-04c687184b57} PushingToViews: Failed to push block to view test_5.v1 (4ae2feef-b6fa-47ac-b20c-744da14b2a0a), Stack size too large. Stack address: 0x7fb7fddf0000, frame address: 0x7fb7fe1ef100, stack size: 4198144, maximum stack size: 8388608 2025.07.28 11:52:58.796029 [ 17207 ] {c88d86d9-1bf7-43f8-8834-04c687184b57} PushingToViews: Failed to push block to view test_5.v2 (7c22a887-3ed3-40f1-a092-d92463e4b87b), Stack size too large. Stack address: 0x7fb7fddf0000, frame address: 0x7fb7fe1ef100, stack size: 4198144, maximum stack size: 8388608 2025.07.28 11:52:58.797567 [ 17207 ] {c88d86d9-1bf7-43f8-8834-04c687184b57} PushingToViews: Failed to push block to view test_5.v1 (4ae2feef-b6fa-47ac-b20c-744da14b2a0a), Stack size too large. Stack address: 0x7fb7fddf0000, frame address: 0x7fb7fe1ef100, stack size: 4198144, maximum stack size: 8388608 2025.07.28 11:52:58.799306 [ 17207 ] {c88d86d9-1bf7-43f8-8834-04c687184b57} PushingToViews: Failed to push block to view test_5.v2 (7c22a887-3ed3-40f1-a092-d92463e4b87b), Stack size too large. Stack address: 0x7fb7fddf0000, frame address: 0x7fb7fe1ef100, stack size: 4198144, maximum stack size: 8388608 2025.07.28 11:52:58.800451 [ 17207 ] {c88d86d9-1bf7-43f8-8834-04c687184b57} PushingToViews: Failed to push block to view test_5.v1 (4ae2feef-b6fa-47ac-b20c-744da14b2a0a), Stack size too large. Stack address: 0x7fb7fddf0000, frame address: 0x7fb7fe1ef100, stack size: 4198144, maximum stack size: 8388608 2025.07.28 11:52:58.801874 [ 17207 ] {c88d86d9-1bf7-43f8-8834-04c687184b57} PushingToViews: Failed to push block to view test_5.v2 (7c22a887-3ed3-40f1-a092-d92463e4b87b), Stack size too large. Stack address: 0x7fb7fddf0000, frame address: 0x7fb7fe1ef100, stack size: 4198144, maximum stack size: 8388608 2025.07.28 11:52:58.803461 [ 17207 ] {c88d86d9-1bf7-43f8-8834-04c687184b57} PushingToViews: Failed to push block to view test_5.v1 (4ae2feef-b6fa-47ac-b20c-744da14b2a0a), Stack size too large. Stack address: 0x7fb7fddf0000, frame address: 0x7fb7fe1ef100, stack size: 4198144, maximum stack size: 8388608 2025.07.28 11:52:58.811792 [ 17207 ] {c88d86d9-1bf7-43f8-8834-04c687184b57} PushingToViews: Failed to push block to view test_5.v2 (7c22a887-3ed3-40f1-a092-d92463e4b87b), Stack size too large. Stack address: 0x7fb7fddf0000, frame address: 0x7fb7fe1ef100, stack size: 4198144, maximum stack size: 8388608 2025.07.28 11:52:58.813376 [ 17207 ] {c88d86d9-1bf7-43f8-8834-04c687184b57} PushingToViews: Failed to push block to view test_5.v1 (4ae2feef-b6fa-47ac-b20c-744da14b2a0a), Stack size too large. Stack address: 0x7fb7fddf0000, frame address: 0x7fb7fe1ef100, stack size: 4198144, maximum stack size: 8388608 2025.07.28 11:52:58.815167 [ 17207 ] {c88d86d9-1bf7-43f8-8834-04c687184b57} PushingToViews: Failed to push block to view test_5.v2 (7c22a887-3ed3-40f1-a092-d92463e4b87b), Stack size too large. Stack address: 0x7fb7fddf0000, frame address: 0x7fb7fe1ef100, stack size: 4198144, maximum stack size: 8388608 2025.07.28 11:52:58.866815 [ 17207 ] {c88d86d9-1bf7-43f8-8834-04c687184b57} PushingToViews: Failed to push block to view test_5.v1 (4ae2feef-b6fa-47ac-b20c-744da14b2a0a), Stack size too large. Stack address: 0x7fb7fddf0000, frame address: 0x7fb7fe1ef100, stack size: 4198144, maximum stack size: 8388608 2025.07.28 11:52:58.876463 [ 17207 ] {c88d86d9-1bf7-43f8-8834-04c687184b57} PushingToViews: Failed to push block to view test_5.v2 (7c22a887-3ed3-40f1-a092-d92463e4b87b), Stack size too large. Stack address: 0x7fb7fddf0000, frame address: 0x7fb7fe1ef100, stack size: 4198144, maximum stack size: 8388608 2025.07.28 11:52:58.877964 [ 17207 ] {c88d86d9-1bf7-43f8-8834-04c687184b57} PushingToViews: Failed to push block to view test_5.v1 (4ae2feef-b6fa-47ac-b20c-744da14b2a0a), Stack size too large. Stack address: 0x7fb7fddf0000, frame address: 0x7fb7fe1ef100, stack size: 4198144, maximum stack size: 8388608 2025.07.28 11:52:58.901944 [ 3971 ] {} test_13.rmt2 (7f9b740d-015c-470e-8cc6-8ba33be0dc63): auto DB::StorageReplicatedMergeTree::processQueueEntry(ReplicatedMergeTreeQueue::SelectedEntryPtr)::(anonymous class)::operator()(LogEntryPtr &) const: Code: 86. DB::HTTPException: Received error from remote server http://146b4357c08d:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Ftest%2F01165%2Ftest_13%2Frmt%2Freplicas%2F1&part=20250728_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.6.10636.altinitytest (altinity build)) '. (RECEIVED_ERROR_FROM_REMOTE_IO_SERVER), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.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 const&, int&&, String const&, unsigned long&&, String const&) @ 0x000000000feda8d9 4. /build/src/IO/HTTPCommon.cpp:104: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x000000000feda6e2 5. /build/src/IO/HTTPCommon.cpp:93: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x000000000feda537 6. /build/src/IO/ReadWriteBufferFromHTTP.cpp:277: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x000000001184a4c4 7. /build/src/IO/ReadWriteBufferFromHTTP.cpp:285: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x000000001184a615 8. /build/src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x000000001184ae59 9. /build/src/IO/ReadWriteBufferFromHTTP.cpp:472: void std::__function::__policy_invoker::__call_impl[abi:se190107]>(std::__function::__policy_storage const*) @ 0x000000001184cedd 10. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001184858b 11. /build/src/IO/ReadWriteBufferFromHTTP.cpp:465: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x000000001184bf0b 12. /build/src/IO/ReadBuffer.h:60: DB::ReadBuffer::next() @ 0x000000000a148c7b 13. /build/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) @ 0x0000000011849fb2 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]>&)>&, 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&) @ 0x0000000011841980 15. /build/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) @ 0x000000001621208e 16. /build/src/Storages/StorageReplicatedMergeTree.cpp:5228: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl[abi:se190107] const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000015f9a5fe 17. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000015ed8bfd 18. /build/src/Storages/StorageReplicatedMergeTree.cpp:2514: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x0000000015ec9aab 19. /build/src/Storages/StorageReplicatedMergeTree.cpp:2349: DB::StorageReplicatedMergeTree::executeLogEntry(DB::ReplicatedMergeTreeLogEntry&) @ 0x0000000015eba91b 20. /build/src/Storages/StorageReplicatedMergeTree.cpp:3876: bool std::__function::__policy_invoker&)>::__call_impl[abi:se190107])::$_1, bool (std::shared_ptr&)>>(std::__function::__policy_storage const*, std::shared_ptr&) @ 0x0000000015f9837e 21. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000165d6fc3 22. /build/src/Storages/StorageReplicatedMergeTree.cpp:3872: DB::StorageReplicatedMergeTree::processQueueEntry(std::shared_ptr) @ 0x0000000015efc18a 23. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001624c1b2 24. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000162f9c70 25. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x00000000162fa55a 26. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc6653 27. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000000fccc4c3 28. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc3d92 29. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fcca080 30. ? @ 0x00007fbc6213eac3 31. ? @ 0x00007fbc621d0850 (version 25.3.6.10636.altinitytest (altinity build)) 2025.07.28 11:52:58.964854 [ 17207 ] {c88d86d9-1bf7-43f8-8834-04c687184b57} PushingToViews: Failed to push block to view test_5.v2 (7c22a887-3ed3-40f1-a092-d92463e4b87b), Stack size too large. Stack address: 0x7fb7fddf0000, frame address: 0x7fb7fe1ef100, stack size: 4198144, maximum stack size: 8388608 2025.07.28 11:52:58.966365 [ 17207 ] {c88d86d9-1bf7-43f8-8834-04c687184b57} PushingToViews: Failed to push block to view test_5.v1 (4ae2feef-b6fa-47ac-b20c-744da14b2a0a), Stack size too large. Stack address: 0x7fb7fddf0000, frame address: 0x7fb7fe1ef100, stack size: 4198144, maximum stack size: 8388608 2025.07.28 11:52:58.967916 [ 17207 ] {c88d86d9-1bf7-43f8-8834-04c687184b57} PushingToViews: Failed to push block to view test_5.v2 (7c22a887-3ed3-40f1-a092-d92463e4b87b), Stack size too large. Stack address: 0x7fb7fddf0000, frame address: 0x7fb7fe1ef100, stack size: 4198144, maximum stack size: 8388608 2025.07.28 11:52:58.969029 [ 17207 ] {c88d86d9-1bf7-43f8-8834-04c687184b57} PushingToViews: Failed to push block to view test_5.v1 (4ae2feef-b6fa-47ac-b20c-744da14b2a0a), Stack size too large. Stack address: 0x7fb7fddf0000, frame address: 0x7fb7fe1ef100, stack size: 4198144, maximum stack size: 8388608 2025.07.28 11:52:58.971183 [ 17207 ] {c88d86d9-1bf7-43f8-8834-04c687184b57} PushingToViews: Failed to push block to view test_5.v2 (7c22a887-3ed3-40f1-a092-d92463e4b87b), Stack size too large. Stack address: 0x7fb7fddf0000, frame address: 0x7fb7fe1ef100, stack size: 4198144, maximum stack size: 8388608 2025.07.28 11:52:58.972561 [ 17207 ] {c88d86d9-1bf7-43f8-8834-04c687184b57} PushingToViews: Failed to push block to view test_5.v1 (4ae2feef-b6fa-47ac-b20c-744da14b2a0a), Stack size too large. Stack address: 0x7fb7fddf0000, frame address: 0x7fb7fe1ef100, stack size: 4198144, maximum stack size: 8388608 2025.07.28 11:52:58.976014 [ 17207 ] {c88d86d9-1bf7-43f8-8834-04c687184b57} PushingToViews: Failed to push block to view test_5.v2 (7c22a887-3ed3-40f1-a092-d92463e4b87b), Stack size too large. Stack address: 0x7fb7fddf0000, frame address: 0x7fb7fe1ef100, stack size: 4198144, maximum stack size: 8388608 2025.07.28 11:52:58.984863 [ 17207 ] {c88d86d9-1bf7-43f8-8834-04c687184b57} PushingToViews: Failed to push block to view test_5.v1 (4ae2feef-b6fa-47ac-b20c-744da14b2a0a), Stack size too large. Stack address: 0x7fb7fddf0000, frame address: 0x7fb7fe1ef100, stack size: 4198144, maximum stack size: 8388608 2025.07.28 11:52:58.991370 [ 17207 ] {c88d86d9-1bf7-43f8-8834-04c687184b57} PushingToViews: Failed to push block to view test_5.v2 (7c22a887-3ed3-40f1-a092-d92463e4b87b), Stack size too large. Stack address: 0x7fb7fddf0000, frame address: 0x7fb7fe1ef100, stack size: 4198144, maximum stack size: 8388608 2025.07.28 11:52:58.993384 [ 17207 ] {c88d86d9-1bf7-43f8-8834-04c687184b57} PushingToViews: Failed to push block to view test_5.v1 (4ae2feef-b6fa-47ac-b20c-744da14b2a0a), Stack size too large. Stack address: 0x7fb7fddf0000, frame address: 0x7fb7fe1ef100, stack size: 4198144, maximum stack size: 8388608 2025.07.28 11:52:58.996083 [ 17207 ] {c88d86d9-1bf7-43f8-8834-04c687184b57} PushingToViews: Failed to push block to view test_5.v2 (7c22a887-3ed3-40f1-a092-d92463e4b87b), Stack size too large. Stack address: 0x7fb7fddf0000, frame address: 0x7fb7fe1ef100, stack size: 4198144, maximum stack size: 8388608 2025.07.28 11:52:58.997710 [ 17207 ] {c88d86d9-1bf7-43f8-8834-04c687184b57} PushingToViews: Failed to push block to view test_5.v1 (4ae2feef-b6fa-47ac-b20c-744da14b2a0a), Stack size too large. Stack address: 0x7fb7fddf0000, frame address: 0x7fb7fe1ef100, stack size: 4198144, maximum stack size: 8388608 2025.07.28 11:52:58.999417 [ 17207 ] {c88d86d9-1bf7-43f8-8834-04c687184b57} PushingToViews: Failed to push block to view test_5.v2 (7c22a887-3ed3-40f1-a092-d92463e4b87b), Stack size too large. Stack address: 0x7fb7fddf0000, frame address: 0x7fb7fe1ef100, stack size: 4198144, maximum stack size: 8388608 2025.07.28 11:52:59.009870 [ 17207 ] {c88d86d9-1bf7-43f8-8834-04c687184b57} PushingToViews: Failed to push block to view test_5.v1 (4ae2feef-b6fa-47ac-b20c-744da14b2a0a), Stack size too large. Stack address: 0x7fb7fddf0000, frame address: 0x7fb7fe1ef100, stack size: 4198144, maximum stack size: 8388608 2025.07.28 11:52:59.012505 [ 17207 ] {c88d86d9-1bf7-43f8-8834-04c687184b57} PushingToViews: Failed to push block to view test_5.v2 (7c22a887-3ed3-40f1-a092-d92463e4b87b), Stack size too large. Stack address: 0x7fb7fddf0000, frame address: 0x7fb7fe1ef100, stack size: 4198144, maximum stack size: 8388608 2025.07.28 11:52:59.014305 [ 17207 ] {c88d86d9-1bf7-43f8-8834-04c687184b57} PushingToViews: Failed to push block to view test_5.v1 (4ae2feef-b6fa-47ac-b20c-744da14b2a0a), Stack size too large. Stack address: 0x7fb7fddf0000, frame address: 0x7fb7fe1ef100, stack size: 4198144, maximum stack size: 8388608 2025.07.28 11:52:59.015946 [ 17207 ] {c88d86d9-1bf7-43f8-8834-04c687184b57} PushingToViews: Failed to push block to view test_5.v2 (7c22a887-3ed3-40f1-a092-d92463e4b87b), Stack size too large. Stack address: 0x7fb7fddf0000, frame address: 0x7fb7fe1ef100, stack size: 4198144, maximum stack size: 8388608 2025.07.28 11:52:59.017944 [ 17207 ] {c88d86d9-1bf7-43f8-8834-04c687184b57} PushingToViews: Failed to push block to view test_5.v1 (4ae2feef-b6fa-47ac-b20c-744da14b2a0a), Stack size too large. Stack address: 0x7fb7fddf0000, frame address: 0x7fb7fe1ef100, stack size: 4198144, maximum stack size: 8388608 2025.07.28 11:52:59.019278 [ 17207 ] {c88d86d9-1bf7-43f8-8834-04c687184b57} PushingToViews: Failed to push block to view test_5.v2 (7c22a887-3ed3-40f1-a092-d92463e4b87b), Stack size too large. Stack address: 0x7fb7fddf0000, frame address: 0x7fb7fe1ef100, stack size: 4198144, maximum stack size: 8388608 2025.07.28 11:52:59.031595 [ 17207 ] {c88d86d9-1bf7-43f8-8834-04c687184b57} PushingToViews: Failed to push block to view test_5.v1 (4ae2feef-b6fa-47ac-b20c-744da14b2a0a), Stack size too large. Stack address: 0x7fb7fddf0000, frame address: 0x7fb7fe1ef100, stack size: 4198144, maximum stack size: 8388608 2025.07.28 11:52:59.052061 [ 17207 ] {c88d86d9-1bf7-43f8-8834-04c687184b57} PushingToViews: Failed to push block to view test_5.v2 (7c22a887-3ed3-40f1-a092-d92463e4b87b), Stack size too large. Stack address: 0x7fb7fddf0000, frame address: 0x7fb7fe1ef100, stack size: 4198144, maximum stack size: 8388608 2025.07.28 11:52:59.065593 [ 17207 ] {c88d86d9-1bf7-43f8-8834-04c687184b57} PushingToViews: Failed to push block to view test_5.v1 (4ae2feef-b6fa-47ac-b20c-744da14b2a0a), Stack size too large. Stack address: 0x7fb7fddf0000, frame address: 0x7fb7fe1ef100, stack size: 4198144, maximum stack size: 8388608 2025.07.28 11:52:59.069111 [ 17207 ] {c88d86d9-1bf7-43f8-8834-04c687184b57} PushingToViews: Failed to push block to view test_5.v2 (7c22a887-3ed3-40f1-a092-d92463e4b87b), Stack size too large. Stack address: 0x7fb7fddf0000, frame address: 0x7fb7fe1ef100, stack size: 4198144, maximum stack size: 8388608 2025.07.28 11:52:59.079384 [ 17207 ] {c88d86d9-1bf7-43f8-8834-04c687184b57} PushingToViews: Failed to push block to view test_5.v1 (4ae2feef-b6fa-47ac-b20c-744da14b2a0a), Stack size too large. Stack address: 0x7fb7fddf0000, frame address: 0x7fb7fe1ef100, stack size: 4198144, maximum stack size: 8388608 2025.07.28 11:52:59.080404 [ 17207 ] {c88d86d9-1bf7-43f8-8834-04c687184b57} PushingToViews: Failed to push block to view test_5.v2 (7c22a887-3ed3-40f1-a092-d92463e4b87b), Stack size too large. Stack address: 0x7fb7fddf0000, frame address: 0x7fb7fe1ef100, stack size: 4198144, maximum stack size: 8388608 2025.07.28 11:52:59.081544 [ 17207 ] {c88d86d9-1bf7-43f8-8834-04c687184b57} PushingToViews: Failed to push block to view test_5.v1 (4ae2feef-b6fa-47ac-b20c-744da14b2a0a), Stack size too large. Stack address: 0x7fb7fddf0000, frame address: 0x7fb7fe1ef100, stack size: 4198144, maximum stack size: 8388608 2025.07.28 11:52:59.084882 [ 3287 ] {cffbab0a-9437-4988-acd9-497c4c70281a} executeQuery: Code: 69. DB::Exception: Scale argument for rounding function is too large: In scope SELECT round(toDecimal32(1, 0), -9223372036854775806). (ARGUMENT_OUT_OF_BOUND) (version 25.3.6.10636.altinitytest (altinity build)) (from [::1]:47608) (comment: 01535_decimal_round_scale_overflow_check.sql) (query 1, line 1) (in query: SELECT round(toDecimal32(1, 0), -9223372036854775806);), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000000a074fcb 4. /build/src/Functions/FunctionsRound.h:516: COW::immutable_ptr DB::Dispatcher, (DB::RoundingMode)8, (DB::TieBreakingMode)0>::apply(DB::IColumn const*, DB::IColumn const*) @ 0x000000000a70a1c8 5. /build/src/Functions/FunctionsRound.h:720: bool DB::FunctionRounding::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&)::operator()>>(auto const&) const @ 0x000000000a6a6b2c 6. /build/src/Core/callOnTypeIndex.h:53: DB::FunctionRounding::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000a6a19c8 7. /build/src/Functions/IFunction.h:437: DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000a069f2a 8. /build/src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000012d9965a 9. /build/src/Functions/IFunction.cpp:351: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d93b02 10. /build/src/Functions/IFunction.cpp:177: DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d93698 11. /build/src/Functions/IFunction.cpp:343: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d93aad 12. /build/src/Functions/IFunction.cpp:420: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d95059 13. /build/src/Functions/IFunction.cpp:498: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d95c72 14. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3567: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000014034494 15. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3838: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000014019a9e 16. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3980: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000014018e31 17. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:4304: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000014042fa7 18. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5605: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000014013749 19. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000140127f9 20. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000014011fce 21. /build/src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000001406ce8a 22. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000014973b42 23. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000001497268d 24. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000014974d24 25. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001492924b 26. /build/src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88641 27. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 28. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 29. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 30. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 31. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 2025.07.28 11:52:59.085068 [ 17207 ] {c88d86d9-1bf7-43f8-8834-04c687184b57} PushingToViews: Failed to push block to view test_5.v2 (7c22a887-3ed3-40f1-a092-d92463e4b87b), Stack size too large. Stack address: 0x7fb7fddf0000, frame address: 0x7fb7fe1ef100, stack size: 4198144, maximum stack size: 8388608 2025.07.28 11:52:59.086280 [ 17207 ] {c88d86d9-1bf7-43f8-8834-04c687184b57} PushingToViews: Failed to push block to view test_5.v1 (4ae2feef-b6fa-47ac-b20c-744da14b2a0a), Stack size too large. Stack address: 0x7fb7fddf0000, frame address: 0x7fb7fe1ef100, stack size: 4198144, maximum stack size: 8388608 2025.07.28 11:52:59.087495 [ 17207 ] {c88d86d9-1bf7-43f8-8834-04c687184b57} PushingToViews: Failed to push block to view test_5.v2 (7c22a887-3ed3-40f1-a092-d92463e4b87b), Stack size too large. Stack address: 0x7fb7fddf0000, frame address: 0x7fb7fe1ef100, stack size: 4198144, maximum stack size: 8388608 2025.07.28 11:52:59.088777 [ 17207 ] {c88d86d9-1bf7-43f8-8834-04c687184b57} PushingToViews: Failed to push block to view test_5.v1 (4ae2feef-b6fa-47ac-b20c-744da14b2a0a), Stack size too large. Stack address: 0x7fb7fddf0000, frame address: 0x7fb7fe1ef100, stack size: 4198144, maximum stack size: 8388608 2025.07.28 11:52:59.089204 [ 3287 ] {} TCPHandler: Code: 69. DB::Exception: Scale argument for rounding function is too large: In scope SELECT round(toDecimal32(1, 0), -9223372036854775806). (ARGUMENT_OUT_OF_BOUND), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000000a074fcb 4. /build/src/Functions/FunctionsRound.h:516: COW::immutable_ptr DB::Dispatcher, (DB::RoundingMode)8, (DB::TieBreakingMode)0>::apply(DB::IColumn const*, DB::IColumn const*) @ 0x000000000a70a1c8 5. /build/src/Functions/FunctionsRound.h:720: bool DB::FunctionRounding::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&)::operator()>>(auto const&) const @ 0x000000000a6a6b2c 6. /build/src/Core/callOnTypeIndex.h:53: DB::FunctionRounding::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000a6a19c8 7. /build/src/Functions/IFunction.h:437: DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000a069f2a 8. /build/src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000012d9965a 9. /build/src/Functions/IFunction.cpp:351: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d93b02 10. /build/src/Functions/IFunction.cpp:177: DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d93698 11. /build/src/Functions/IFunction.cpp:343: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d93aad 12. /build/src/Functions/IFunction.cpp:420: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d95059 13. /build/src/Functions/IFunction.cpp:498: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d95c72 14. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3567: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000014034494 15. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3838: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000014019a9e 16. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3980: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000014018e31 17. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:4304: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000014042fa7 18. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5605: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000014013749 19. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000140127f9 20. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000014011fce 21. /build/src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000001406ce8a 22. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000014973b42 23. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000001497268d 24. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000014974d24 25. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001492924b 26. /build/src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88641 27. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 28. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 29. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 30. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 31. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 2025.07.28 11:52:59.092601 [ 17207 ] {c88d86d9-1bf7-43f8-8834-04c687184b57} PushingToViews: Failed to push block to view test_5.v2 (7c22a887-3ed3-40f1-a092-d92463e4b87b), Stack size too large. Stack address: 0x7fb7fddf0000, frame address: 0x7fb7fe1ef100, stack size: 4198144, maximum stack size: 8388608 2025.07.28 11:52:59.099666 [ 17207 ] {c88d86d9-1bf7-43f8-8834-04c687184b57} PushingToViews: Failed to push block to view test_5.v1 (4ae2feef-b6fa-47ac-b20c-744da14b2a0a), Stack size too large. Stack address: 0x7fb7fddf0000, frame address: 0x7fb7fe1ef100, stack size: 4198144, maximum stack size: 8388608 2025.07.28 11:52:59.100761 [ 17207 ] {c88d86d9-1bf7-43f8-8834-04c687184b57} PushingToViews: Failed to push block to view test_5.v2 (7c22a887-3ed3-40f1-a092-d92463e4b87b), Stack size too large. Stack address: 0x7fb7fddf0000, frame address: 0x7fb7fe1ef100, stack size: 4198144, maximum stack size: 8388608 2025.07.28 11:52:59.102961 [ 17207 ] {c88d86d9-1bf7-43f8-8834-04c687184b57} PushingToViews: Failed to push block to view test_5.v1 (4ae2feef-b6fa-47ac-b20c-744da14b2a0a), Stack size too large. Stack address: 0x7fb7fddf0000, frame address: 0x7fb7fe1ef100, stack size: 4198144, maximum stack size: 8388608 2025.07.28 11:52:59.104039 [ 17207 ] {c88d86d9-1bf7-43f8-8834-04c687184b57} PushingToViews: Failed to push block to view test_5.v2 (7c22a887-3ed3-40f1-a092-d92463e4b87b), Stack size too large. Stack address: 0x7fb7fddf0000, frame address: 0x7fb7fe1ef100, stack size: 4198144, maximum stack size: 8388608 2025.07.28 11:52:59.105288 [ 17207 ] {c88d86d9-1bf7-43f8-8834-04c687184b57} PushingToViews: Failed to push block to view test_5.v1 (4ae2feef-b6fa-47ac-b20c-744da14b2a0a), Stack size too large. Stack address: 0x7fb7fddf0000, frame address: 0x7fb7fe1ef100, stack size: 4198144, maximum stack size: 8388608 2025.07.28 11:52:59.107489 [ 17207 ] {c88d86d9-1bf7-43f8-8834-04c687184b57} PushingToViews: Failed to push block to view test_5.v2 (7c22a887-3ed3-40f1-a092-d92463e4b87b), Stack size too large. Stack address: 0x7fb7fddf0000, frame address: 0x7fb7fe1ef100, stack size: 4198144, maximum stack size: 8388608 2025.07.28 11:52:59.110218 [ 17207 ] {c88d86d9-1bf7-43f8-8834-04c687184b57} PushingToViews: Failed to push block to view test_5.v1 (4ae2feef-b6fa-47ac-b20c-744da14b2a0a), Stack size too large. Stack address: 0x7fb7fddf0000, frame address: 0x7fb7fe1ef100, stack size: 4198144, maximum stack size: 8388608 2025.07.28 11:52:59.111251 [ 17207 ] {c88d86d9-1bf7-43f8-8834-04c687184b57} PushingToViews: Failed to push block to view test_5.v2 (7c22a887-3ed3-40f1-a092-d92463e4b87b), Stack size too large. Stack address: 0x7fb7fddf0000, frame address: 0x7fb7fe1ef100, stack size: 4198144, maximum stack size: 8388608 2025.07.28 11:52:59.112692 [ 17207 ] {c88d86d9-1bf7-43f8-8834-04c687184b57} PushingToViews: Failed to push block to view test_5.v1 (4ae2feef-b6fa-47ac-b20c-744da14b2a0a), Stack size too large. Stack address: 0x7fb7fddf0000, frame address: 0x7fb7fe1ef100, stack size: 4198144, maximum stack size: 8388608 2025.07.28 11:52:59.125402 [ 17207 ] {c88d86d9-1bf7-43f8-8834-04c687184b57} PushingToViews: Failed to push block to view test_5.v2 (7c22a887-3ed3-40f1-a092-d92463e4b87b), Stack size too large. Stack address: 0x7fb7fddf0000, frame address: 0x7fb7fe1ef100, stack size: 4198144, maximum stack size: 8388608 2025.07.28 11:52:59.155569 [ 17207 ] {c88d86d9-1bf7-43f8-8834-04c687184b57} PushingToViews: Failed to push block to view test_5.v1 (4ae2feef-b6fa-47ac-b20c-744da14b2a0a), Stack size too large. Stack address: 0x7fb7fddf0000, frame address: 0x7fb7fe1ef100, stack size: 4198144, maximum stack size: 8388608 2025.07.28 11:52:59.158681 [ 17207 ] {c88d86d9-1bf7-43f8-8834-04c687184b57} PushingToViews: Failed to push block to view test_5.v2 (7c22a887-3ed3-40f1-a092-d92463e4b87b), Stack size too large. Stack address: 0x7fb7fddf0000, frame address: 0x7fb7fe1ef100, stack size: 4198144, maximum stack size: 8388608 2025.07.28 11:52:59.160943 [ 17207 ] {c88d86d9-1bf7-43f8-8834-04c687184b57} PushingToViews: Failed to push block to view test_5.v1 (4ae2feef-b6fa-47ac-b20c-744da14b2a0a), Stack size too large. Stack address: 0x7fb7fddf0000, frame address: 0x7fb7fe1ef100, stack size: 4198144, maximum stack size: 8388608 2025.07.28 11:52:59.169380 [ 17207 ] {c88d86d9-1bf7-43f8-8834-04c687184b57} PushingToViews: Failed to push block to view test_5.v2 (7c22a887-3ed3-40f1-a092-d92463e4b87b), Stack size too large. Stack address: 0x7fb7fddf0000, frame address: 0x7fb7fe1ef100, stack size: 4198144, maximum stack size: 8388608 2025.07.28 11:52:59.170756 [ 17207 ] {c88d86d9-1bf7-43f8-8834-04c687184b57} PushingToViews: Failed to push block to view test_5.v1 (4ae2feef-b6fa-47ac-b20c-744da14b2a0a), Stack size too large. Stack address: 0x7fb7fddf0000, frame address: 0x7fb7fe1ef100, stack size: 4198144, maximum stack size: 8388608 2025.07.28 11:52:59.175998 [ 17207 ] {c88d86d9-1bf7-43f8-8834-04c687184b57} PushingToViews: Failed to push block to view test_5.v2 (7c22a887-3ed3-40f1-a092-d92463e4b87b), Stack size too large. Stack address: 0x7fb7fddf0000, frame address: 0x7fb7fe1ef100, stack size: 4198144, maximum stack size: 8388608 2025.07.28 11:52:59.199381 [ 17207 ] {c88d86d9-1bf7-43f8-8834-04c687184b57} PushingToViews: Failed to push block to view test_5.v1 (4ae2feef-b6fa-47ac-b20c-744da14b2a0a), Stack size too large. Stack address: 0x7fb7fddf0000, frame address: 0x7fb7fe1ef100, stack size: 4198144, maximum stack size: 8388608 2025.07.28 11:52:59.204282 [ 17207 ] {c88d86d9-1bf7-43f8-8834-04c687184b57} PushingToViews: Failed to push block to view test_5.v2 (7c22a887-3ed3-40f1-a092-d92463e4b87b), Stack size too large. Stack address: 0x7fb7fddf0000, frame address: 0x7fb7fe1ef100, stack size: 4198144, maximum stack size: 8388608 2025.07.28 11:52:59.219553 [ 17207 ] {c88d86d9-1bf7-43f8-8834-04c687184b57} PushingToViews: Failed to push block to view test_5.v1 (4ae2feef-b6fa-47ac-b20c-744da14b2a0a), Stack size too large. Stack address: 0x7fb7fddf0000, frame address: 0x7fb7fe1ef100, stack size: 4198144, maximum stack size: 8388608 2025.07.28 11:52:59.248123 [ 17207 ] {c88d86d9-1bf7-43f8-8834-04c687184b57} PushingToViews: Failed to push block to view test_5.v2 (7c22a887-3ed3-40f1-a092-d92463e4b87b), Stack size too large. Stack address: 0x7fb7fddf0000, frame address: 0x7fb7fe1ef100, stack size: 4198144, maximum stack size: 8388608 2025.07.28 11:52:59.257371 [ 17207 ] {c88d86d9-1bf7-43f8-8834-04c687184b57} PushingToViews: Failed to push block to view test_5.v1 (4ae2feef-b6fa-47ac-b20c-744da14b2a0a), Stack size too large. Stack address: 0x7fb7fddf0000, frame address: 0x7fb7fe1ef100, stack size: 4198144, maximum stack size: 8388608 2025.07.28 11:52:59.264500 [ 17207 ] {c88d86d9-1bf7-43f8-8834-04c687184b57} PushingToViews: Failed to push block to view test_5.v2 (7c22a887-3ed3-40f1-a092-d92463e4b87b), Stack size too large. Stack address: 0x7fb7fddf0000, frame address: 0x7fb7fe1ef100, stack size: 4198144, maximum stack size: 8388608 2025.07.28 11:52:59.269164 [ 17207 ] {c88d86d9-1bf7-43f8-8834-04c687184b57} PushingToViews: Failed to push block to view test_5.v1 (4ae2feef-b6fa-47ac-b20c-744da14b2a0a), Stack size too large. Stack address: 0x7fb7fddf0000, frame address: 0x7fb7fe1ef100, stack size: 4198144, maximum stack size: 8388608 2025.07.28 11:52:59.271640 [ 17207 ] {c88d86d9-1bf7-43f8-8834-04c687184b57} PushingToViews: Failed to push block to view test_5.v2 (7c22a887-3ed3-40f1-a092-d92463e4b87b), Stack size too large. Stack address: 0x7fb7fddf0000, frame address: 0x7fb7fe1ef100, stack size: 4198144, maximum stack size: 8388608 2025.07.28 11:52:59.273139 [ 17207 ] {c88d86d9-1bf7-43f8-8834-04c687184b57} PushingToViews: Failed to push block to view test_5.v1 (4ae2feef-b6fa-47ac-b20c-744da14b2a0a), Stack size too large. Stack address: 0x7fb7fddf0000, frame address: 0x7fb7fe1ef100, stack size: 4198144, maximum stack size: 8388608 2025.07.28 11:52:59.275979 [ 17207 ] {c88d86d9-1bf7-43f8-8834-04c687184b57} PushingToViews: Failed to push block to view test_5.v2 (7c22a887-3ed3-40f1-a092-d92463e4b87b), Stack size too large. Stack address: 0x7fb7fddf0000, frame address: 0x7fb7fe1ef100, stack size: 4198144, maximum stack size: 8388608 2025.07.28 11:52:59.294724 [ 17207 ] {c88d86d9-1bf7-43f8-8834-04c687184b57} PushingToViews: Failed to push block to view test_5.v1 (4ae2feef-b6fa-47ac-b20c-744da14b2a0a), Stack size too large. Stack address: 0x7fb7fddf0000, frame address: 0x7fb7fe1ef100, stack size: 4198144, maximum stack size: 8388608 2025.07.28 11:52:59.297731 [ 17207 ] {c88d86d9-1bf7-43f8-8834-04c687184b57} PushingToViews: Failed to push block to view test_5.v2 (7c22a887-3ed3-40f1-a092-d92463e4b87b), Stack size too large. Stack address: 0x7fb7fddf0000, frame address: 0x7fb7fe1ef100, stack size: 4198144, maximum stack size: 8388608 2025.07.28 11:52:59.303330 [ 17207 ] {c88d86d9-1bf7-43f8-8834-04c687184b57} PushingToViews: Failed to push block to view test_5.v1 (4ae2feef-b6fa-47ac-b20c-744da14b2a0a), Stack size too large. Stack address: 0x7fb7fddf0000, frame address: 0x7fb7fe1ef100, stack size: 4198144, maximum stack size: 8388608 2025.07.28 11:52:59.313324 [ 17207 ] {c88d86d9-1bf7-43f8-8834-04c687184b57} PushingToViews: Failed to push block to view test_5.v2 (7c22a887-3ed3-40f1-a092-d92463e4b87b), Stack size too large. Stack address: 0x7fb7fddf0000, frame address: 0x7fb7fe1ef100, stack size: 4198144, maximum stack size: 8388608 2025.07.28 11:52:59.325704 [ 17207 ] {c88d86d9-1bf7-43f8-8834-04c687184b57} PushingToViews: Failed to push block to view test_5.v1 (4ae2feef-b6fa-47ac-b20c-744da14b2a0a), Stack size too large. Stack address: 0x7fb7fddf0000, frame address: 0x7fb7fe1ef100, stack size: 4198144, maximum stack size: 8388608 2025.07.28 11:52:59.331850 [ 17207 ] {c88d86d9-1bf7-43f8-8834-04c687184b57} PushingToViews: Failed to push block to view test_5.v2 (7c22a887-3ed3-40f1-a092-d92463e4b87b), Stack size too large. Stack address: 0x7fb7fddf0000, frame address: 0x7fb7fe1ef100, stack size: 4198144, maximum stack size: 8388608 2025.07.28 11:52:59.343935 [ 17207 ] {c88d86d9-1bf7-43f8-8834-04c687184b57} PushingToViews: Failed to push block to view test_5.v1 (4ae2feef-b6fa-47ac-b20c-744da14b2a0a), Stack size too large. Stack address: 0x7fb7fddf0000, frame address: 0x7fb7fe1ef100, stack size: 4198144, maximum stack size: 8388608 2025.07.28 11:52:59.347820 [ 17207 ] {c88d86d9-1bf7-43f8-8834-04c687184b57} PushingToViews: Failed to push block to view test_5.v2 (7c22a887-3ed3-40f1-a092-d92463e4b87b), Stack size too large. Stack address: 0x7fb7fddf0000, frame address: 0x7fb7fe1ef100, stack size: 4198144, maximum stack size: 8388608 2025.07.28 11:52:59.365038 [ 17207 ] {c88d86d9-1bf7-43f8-8834-04c687184b57} PushingToViews: Failed to push block to view test_5.v1 (4ae2feef-b6fa-47ac-b20c-744da14b2a0a), Stack size too large. Stack address: 0x7fb7fddf0000, frame address: 0x7fb7fe1ef100, stack size: 4198144, maximum stack size: 8388608 2025.07.28 11:52:59.370487 [ 17207 ] {c88d86d9-1bf7-43f8-8834-04c687184b57} PushingToViews: Failed to push block to view test_5.v2 (7c22a887-3ed3-40f1-a092-d92463e4b87b), Stack size too large. Stack address: 0x7fb7fddf0000, frame address: 0x7fb7fe1ef100, stack size: 4198144, maximum stack size: 8388608 2025.07.28 11:52:59.374412 [ 17207 ] {c88d86d9-1bf7-43f8-8834-04c687184b57} PushingToViews: Failed to push block to view test_5.v1 (4ae2feef-b6fa-47ac-b20c-744da14b2a0a), Stack size too large. Stack address: 0x7fb7fddf0000, frame address: 0x7fb7fe1ef100, stack size: 4198144, maximum stack size: 8388608 2025.07.28 11:52:59.385315 [ 17207 ] {c88d86d9-1bf7-43f8-8834-04c687184b57} PushingToViews: Failed to push block to view test_5.v2 (7c22a887-3ed3-40f1-a092-d92463e4b87b), Stack size too large. Stack address: 0x7fb7fddf0000, frame address: 0x7fb7fe1ef100, stack size: 4198144, maximum stack size: 8388608 2025.07.28 11:52:59.402066 [ 17207 ] {c88d86d9-1bf7-43f8-8834-04c687184b57} PushingToViews: Failed to push block to view test_5.v1 (4ae2feef-b6fa-47ac-b20c-744da14b2a0a), Stack size too large. Stack address: 0x7fb7fddf0000, frame address: 0x7fb7fe1ef100, stack size: 4198144, maximum stack size: 8388608 2025.07.28 11:52:59.420365 [ 17207 ] {c88d86d9-1bf7-43f8-8834-04c687184b57} PushingToViews: Failed to push block to view test_5.v2 (7c22a887-3ed3-40f1-a092-d92463e4b87b), Stack size too large. Stack address: 0x7fb7fddf0000, frame address: 0x7fb7fe1ef100, stack size: 4198144, maximum stack size: 8388608 2025.07.28 11:52:59.425348 [ 17207 ] {c88d86d9-1bf7-43f8-8834-04c687184b57} PushingToViews: Failed to push block to view test_5.v1 (4ae2feef-b6fa-47ac-b20c-744da14b2a0a), Stack size too large. Stack address: 0x7fb7fddf0000, frame address: 0x7fb7fe1ef100, stack size: 4198144, maximum stack size: 8388608 2025.07.28 11:52:59.428979 [ 17207 ] {c88d86d9-1bf7-43f8-8834-04c687184b57} PushingToViews: Failed to push block to view test_5.v2 (7c22a887-3ed3-40f1-a092-d92463e4b87b), Stack size too large. Stack address: 0x7fb7fddf0000, frame address: 0x7fb7fe1ef100, stack size: 4198144, maximum stack size: 8388608 2025.07.28 11:52:59.432502 [ 17207 ] {c88d86d9-1bf7-43f8-8834-04c687184b57} PushingToViews: Failed to push block to view test_5.v1 (4ae2feef-b6fa-47ac-b20c-744da14b2a0a), Stack size too large. Stack address: 0x7fb7fddf0000, frame address: 0x7fb7fe1ef100, stack size: 4198144, maximum stack size: 8388608 2025.07.28 11:52:59.435629 [ 17207 ] {c88d86d9-1bf7-43f8-8834-04c687184b57} PushingToViews: Failed to push block to view test_5.v2 (7c22a887-3ed3-40f1-a092-d92463e4b87b), Stack size too large. Stack address: 0x7fb7fddf0000, frame address: 0x7fb7fe1ef100, stack size: 4198144, maximum stack size: 8388608 2025.07.28 11:52:59.438164 [ 17207 ] {c88d86d9-1bf7-43f8-8834-04c687184b57} PushingToViews: Failed to push block to view test_5.v1 (4ae2feef-b6fa-47ac-b20c-744da14b2a0a), Stack size too large. Stack address: 0x7fb7fddf0000, frame address: 0x7fb7fe1ef100, stack size: 4198144, maximum stack size: 8388608 2025.07.28 11:52:59.444181 [ 17207 ] {c88d86d9-1bf7-43f8-8834-04c687184b57} PushingToViews: Failed to push block to view test_5.v2 (7c22a887-3ed3-40f1-a092-d92463e4b87b), Stack size too large. Stack address: 0x7fb7fddf0000, frame address: 0x7fb7fe1ef100, stack size: 4198144, maximum stack size: 8388608 2025.07.28 11:52:59.456304 [ 17207 ] {c88d86d9-1bf7-43f8-8834-04c687184b57} PushingToViews: Failed to push block to view test_5.v1 (4ae2feef-b6fa-47ac-b20c-744da14b2a0a), Stack size too large. Stack address: 0x7fb7fddf0000, frame address: 0x7fb7fe1ef100, stack size: 4198144, maximum stack size: 8388608 2025.07.28 11:52:59.472328 [ 17207 ] {c88d86d9-1bf7-43f8-8834-04c687184b57} PushingToViews: Failed to push block to view test_5.v2 (7c22a887-3ed3-40f1-a092-d92463e4b87b), Stack size too large. Stack address: 0x7fb7fddf0000, frame address: 0x7fb7fe1ef100, stack size: 4198144, maximum stack size: 8388608 2025.07.28 11:52:59.481230 [ 17207 ] {c88d86d9-1bf7-43f8-8834-04c687184b57} PushingToViews: Failed to push block to view test_5.v1 (4ae2feef-b6fa-47ac-b20c-744da14b2a0a), Stack size too large. Stack address: 0x7fb7fddf0000, frame address: 0x7fb7fe1ef100, stack size: 4198144, maximum stack size: 8388608 2025.07.28 11:52:59.489921 [ 17207 ] {c88d86d9-1bf7-43f8-8834-04c687184b57} PushingToViews: Failed to push block to view test_5.v2 (7c22a887-3ed3-40f1-a092-d92463e4b87b), Stack size too large. Stack address: 0x7fb7fddf0000, frame address: 0x7fb7fe1ef100, stack size: 4198144, maximum stack size: 8388608 2025.07.28 11:52:59.499442 [ 17207 ] {c88d86d9-1bf7-43f8-8834-04c687184b57} PushingToViews: Failed to push block to view test_5.v1 (4ae2feef-b6fa-47ac-b20c-744da14b2a0a), Stack size too large. Stack address: 0x7fb7fddf0000, frame address: 0x7fb7fe1ef100, stack size: 4198144, maximum stack size: 8388608 2025.07.28 11:52:59.506252 [ 17207 ] {c88d86d9-1bf7-43f8-8834-04c687184b57} PushingToViews: Failed to push block to view test_5.v2 (7c22a887-3ed3-40f1-a092-d92463e4b87b), Stack size too large. Stack address: 0x7fb7fddf0000, frame address: 0x7fb7fe1ef100, stack size: 4198144, maximum stack size: 8388608 2025.07.28 11:52:59.514706 [ 17207 ] {c88d86d9-1bf7-43f8-8834-04c687184b57} PushingToViews: Failed to push block to view test_5.v1 (4ae2feef-b6fa-47ac-b20c-744da14b2a0a), Stack size too large. Stack address: 0x7fb7fddf0000, frame address: 0x7fb7fe1ef100, stack size: 4198144, maximum stack size: 8388608 2025.07.28 11:52:59.606059 [ 17207 ] {c88d86d9-1bf7-43f8-8834-04c687184b57} PushingToViews: Failed to push block to view test_5.v2 (7c22a887-3ed3-40f1-a092-d92463e4b87b), Stack size too large. Stack address: 0x7fb7fddf0000, frame address: 0x7fb7fe1ef100, stack size: 4198144, maximum stack size: 8388608 2025.07.28 11:52:59.610523 [ 17207 ] {c88d86d9-1bf7-43f8-8834-04c687184b57} PushingToViews: Failed to push block to view test_5.v1 (4ae2feef-b6fa-47ac-b20c-744da14b2a0a), Stack size too large. Stack address: 0x7fb7fddf0000, frame address: 0x7fb7fe1ef100, stack size: 4198144, maximum stack size: 8388608 2025.07.28 11:52:59.611875 [ 17207 ] {c88d86d9-1bf7-43f8-8834-04c687184b57} PushingToViews: Failed to push block to view test_5.v2 (7c22a887-3ed3-40f1-a092-d92463e4b87b), Stack size too large. Stack address: 0x7fb7fddf0000, frame address: 0x7fb7fe1ef100, stack size: 4198144, maximum stack size: 8388608 2025.07.28 11:52:59.616007 [ 17207 ] {c88d86d9-1bf7-43f8-8834-04c687184b57} PushingToViews: Failed to push block to view test_5.v1 (4ae2feef-b6fa-47ac-b20c-744da14b2a0a), Stack size too large. Stack address: 0x7fb7fddf0000, frame address: 0x7fb7fe1ef100, stack size: 4198144, maximum stack size: 8388608 2025.07.28 11:52:59.618457 [ 17207 ] {c88d86d9-1bf7-43f8-8834-04c687184b57} PushingToViews: Failed to push block to view test_5.v2 (7c22a887-3ed3-40f1-a092-d92463e4b87b), Stack size too large. Stack address: 0x7fb7fddf0000, frame address: 0x7fb7fe1ef100, stack size: 4198144, maximum stack size: 8388608 2025.07.28 11:52:59.619709 [ 17207 ] {c88d86d9-1bf7-43f8-8834-04c687184b57} PushingToViews: Failed to push block to view test_5.v1 (4ae2feef-b6fa-47ac-b20c-744da14b2a0a), Stack size too large. Stack address: 0x7fb7fddf0000, frame address: 0x7fb7fe1ef100, stack size: 4198144, maximum stack size: 8388608 2025.07.28 11:52:59.620552 [ 17207 ] {c88d86d9-1bf7-43f8-8834-04c687184b57} PushingToViews: Failed to push block to view test_5.v2 (7c22a887-3ed3-40f1-a092-d92463e4b87b), Stack size too large. Stack address: 0x7fb7fddf0000, frame address: 0x7fb7fe1ef100, stack size: 4198144, maximum stack size: 8388608 2025.07.28 11:52:59.622019 [ 17207 ] {c88d86d9-1bf7-43f8-8834-04c687184b57} PushingToViews: Failed to push block to view test_5.v1 (4ae2feef-b6fa-47ac-b20c-744da14b2a0a), Stack size too large. Stack address: 0x7fb7fddf0000, frame address: 0x7fb7fe1ef100, stack size: 4198144, maximum stack size: 8388608 2025.07.28 11:52:59.631393 [ 17207 ] {c88d86d9-1bf7-43f8-8834-04c687184b57} PushingToViews: Failed to push block to view test_5.v2 (7c22a887-3ed3-40f1-a092-d92463e4b87b), Stack size too large. Stack address: 0x7fb7fddf0000, frame address: 0x7fb7fe1ef100, stack size: 4198144, maximum stack size: 8388608 2025.07.28 11:52:59.636297 [ 17207 ] {c88d86d9-1bf7-43f8-8834-04c687184b57} PushingToViews: Failed to push block to view test_5.v1 (4ae2feef-b6fa-47ac-b20c-744da14b2a0a), Stack size too large. Stack address: 0x7fb7fddf0000, frame address: 0x7fb7fe1ef100, stack size: 4198144, maximum stack size: 8388608 2025.07.28 11:52:59.639636 [ 17207 ] {c88d86d9-1bf7-43f8-8834-04c687184b57} PushingToViews: Failed to push block to view test_5.v2 (7c22a887-3ed3-40f1-a092-d92463e4b87b), Stack size too large. Stack address: 0x7fb7fddf0000, frame address: 0x7fb7fe1ef100, stack size: 4198144, maximum stack size: 8388608 2025.07.28 11:52:59.686991 [ 17207 ] {c88d86d9-1bf7-43f8-8834-04c687184b57} PushingToViews: Failed to push block to view test_5.v1 (4ae2feef-b6fa-47ac-b20c-744da14b2a0a), Stack size too large. Stack address: 0x7fb7fddf0000, frame address: 0x7fb7fe1ef100, stack size: 4198144, maximum stack size: 8388608 2025.07.28 11:52:59.701544 [ 17207 ] {c88d86d9-1bf7-43f8-8834-04c687184b57} PushingToViews: Failed to push block to view test_5.v2 (7c22a887-3ed3-40f1-a092-d92463e4b87b), Stack size too large. Stack address: 0x7fb7fddf0000, frame address: 0x7fb7fe1ef100, stack size: 4198144, maximum stack size: 8388608 2025.07.28 11:52:59.701777 [ 5327 ] {} TCPHandler: Code: 394. DB::Exception: Query '5eeb1759-ef8d-472c-92c2-62a453a651ac' is killed in pending state. (QUERY_WAS_CANCELLED), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x000000000a06b56b 4. /build/src/Interpreters/executeQuery.cpp:1522: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c8a4ef 5. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 6. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 7. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 8. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 9. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 10. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 11. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 12. ? @ 0x00007fbc6213eac3 13. ? @ 0x00007fbc621d0850 2025.07.28 11:52:59.702870 [ 17207 ] {c88d86d9-1bf7-43f8-8834-04c687184b57} PushingToViews: Failed to push block to view test_5.v1 (4ae2feef-b6fa-47ac-b20c-744da14b2a0a), Stack size too large. Stack address: 0x7fb7fddf0000, frame address: 0x7fb7fe1ef100, stack size: 4198144, maximum stack size: 8388608 2025.07.28 11:52:59.706211 [ 3967 ] {} test_13.rmt2 (7f9b740d-015c-470e-8cc6-8ba33be0dc63): auto DB::StorageReplicatedMergeTree::processQueueEntry(ReplicatedMergeTreeQueue::SelectedEntryPtr)::(anonymous class)::operator()(LogEntryPtr &) const: Code: 86. DB::HTTPException: Received error from remote server http://146b4357c08d:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Ftest%2F01165%2Ftest_13%2Frmt%2Freplicas%2F1&part=20250728_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.6.10636.altinitytest (altinity build)) '. (RECEIVED_ERROR_FROM_REMOTE_IO_SERVER), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.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 const&, int&&, String const&, unsigned long&&, String const&) @ 0x000000000feda8d9 4. /build/src/IO/HTTPCommon.cpp:104: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x000000000feda6e2 5. /build/src/IO/HTTPCommon.cpp:93: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x000000000feda537 6. /build/src/IO/ReadWriteBufferFromHTTP.cpp:277: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x000000001184a4c4 7. /build/src/IO/ReadWriteBufferFromHTTP.cpp:285: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x000000001184a615 8. /build/src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x000000001184ae59 9. /build/src/IO/ReadWriteBufferFromHTTP.cpp:472: void std::__function::__policy_invoker::__call_impl[abi:se190107]>(std::__function::__policy_storage const*) @ 0x000000001184cedd 10. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001184858b 11. /build/src/IO/ReadWriteBufferFromHTTP.cpp:465: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x000000001184bf0b 12. /build/src/IO/ReadBuffer.h:60: DB::ReadBuffer::next() @ 0x000000000a148c7b 13. /build/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) @ 0x0000000011849fb2 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]>&)>&, 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&) @ 0x0000000011841980 15. /build/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) @ 0x000000001621208e 16. /build/src/Storages/StorageReplicatedMergeTree.cpp:5228: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl[abi:se190107] const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000015f9a5fe 17. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000015ed8bfd 18. /build/src/Storages/StorageReplicatedMergeTree.cpp:2514: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x0000000015ec9aab 19. /build/src/Storages/StorageReplicatedMergeTree.cpp:2349: DB::StorageReplicatedMergeTree::executeLogEntry(DB::ReplicatedMergeTreeLogEntry&) @ 0x0000000015eba91b 20. /build/src/Storages/StorageReplicatedMergeTree.cpp:3876: bool std::__function::__policy_invoker&)>::__call_impl[abi:se190107])::$_1, bool (std::shared_ptr&)>>(std::__function::__policy_storage const*, std::shared_ptr&) @ 0x0000000015f9837e 21. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000165d6fc3 22. /build/src/Storages/StorageReplicatedMergeTree.cpp:3872: DB::StorageReplicatedMergeTree::processQueueEntry(std::shared_ptr) @ 0x0000000015efc18a 23. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001624c1b2 24. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000162f9c70 25. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x00000000162fa55a 26. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc6653 27. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000000fccc4c3 28. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc3d92 29. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fcca080 30. ? @ 0x00007fbc6213eac3 31. ? @ 0x00007fbc621d0850 (version 25.3.6.10636.altinitytest (altinity build)) 2025.07.28 11:52:59.708342 [ 17207 ] {c88d86d9-1bf7-43f8-8834-04c687184b57} PushingToViews: Failed to push block to view test_5.v2 (7c22a887-3ed3-40f1-a092-d92463e4b87b), Stack size too large. Stack address: 0x7fb7fddf0000, frame address: 0x7fb7fe1ef100, stack size: 4198144, maximum stack size: 8388608 2025.07.28 11:52:59.719814 [ 17207 ] {c88d86d9-1bf7-43f8-8834-04c687184b57} PushingToViews: Failed to push block to view test_5.v1 (4ae2feef-b6fa-47ac-b20c-744da14b2a0a), Stack size too large. Stack address: 0x7fb7fddf0000, frame address: 0x7fb7fe1ef100, stack size: 4198144, maximum stack size: 8388608 2025.07.28 11:52:59.720594 [ 17207 ] {c88d86d9-1bf7-43f8-8834-04c687184b57} PushingToViews: Failed to push block to view test_5.v2 (7c22a887-3ed3-40f1-a092-d92463e4b87b), Stack size too large. Stack address: 0x7fb7fddf0000, frame address: 0x7fb7fe1ef100, stack size: 4198144, maximum stack size: 8388608 2025.07.28 11:52:59.724684 [ 17207 ] {c88d86d9-1bf7-43f8-8834-04c687184b57} PushingToViews: Failed to push block to view test_5.v1 (4ae2feef-b6fa-47ac-b20c-744da14b2a0a), Stack size too large. Stack address: 0x7fb7fddf0000, frame address: 0x7fb7fe1ef100, stack size: 4198144, maximum stack size: 8388608 2025.07.28 11:52:59.726127 [ 17207 ] {c88d86d9-1bf7-43f8-8834-04c687184b57} PushingToViews: Failed to push block to view test_5.v2 (7c22a887-3ed3-40f1-a092-d92463e4b87b), Stack size too large. Stack address: 0x7fb7fddf0000, frame address: 0x7fb7fe1ef100, stack size: 4198144, maximum stack size: 8388608 2025.07.28 11:52:59.729217 [ 17207 ] {c88d86d9-1bf7-43f8-8834-04c687184b57} PushingToViews: Failed to push block to view test_5.v1 (4ae2feef-b6fa-47ac-b20c-744da14b2a0a), Stack size too large. Stack address: 0x7fb7fddf0000, frame address: 0x7fb7fe1ef100, stack size: 4198144, maximum stack size: 8388608 2025.07.28 11:52:59.730077 [ 17207 ] {c88d86d9-1bf7-43f8-8834-04c687184b57} PushingToViews: Failed to push block to view test_5.v2 (7c22a887-3ed3-40f1-a092-d92463e4b87b), Stack size too large. Stack address: 0x7fb7fddf0000, frame address: 0x7fb7fe1ef100, stack size: 4198144, maximum stack size: 8388608 2025.07.28 11:52:59.736363 [ 17207 ] {c88d86d9-1bf7-43f8-8834-04c687184b57} PushingToViews: Failed to push block to view test_5.v1 (4ae2feef-b6fa-47ac-b20c-744da14b2a0a), Stack size too large. Stack address: 0x7fb7fddf0000, frame address: 0x7fb7fe1ef100, stack size: 4198144, maximum stack size: 8388608 2025.07.28 11:52:59.737176 [ 17207 ] {c88d86d9-1bf7-43f8-8834-04c687184b57} PushingToViews: Failed to push block to view test_5.v2 (7c22a887-3ed3-40f1-a092-d92463e4b87b), Stack size too large. Stack address: 0x7fb7fddf0000, frame address: 0x7fb7fe1ef100, stack size: 4198144, maximum stack size: 8388608 2025.07.28 11:52:59.738564 [ 17207 ] {c88d86d9-1bf7-43f8-8834-04c687184b57} PushingToViews: Failed to push block to view test_5.v1 (4ae2feef-b6fa-47ac-b20c-744da14b2a0a), Stack size too large. Stack address: 0x7fb7fddf0000, frame address: 0x7fb7fe1ef100, stack size: 4198144, maximum stack size: 8388608 2025.07.28 11:52:59.742011 [ 17207 ] {c88d86d9-1bf7-43f8-8834-04c687184b57} PushingToViews: Failed to push block to view test_5.v2 (7c22a887-3ed3-40f1-a092-d92463e4b87b), Stack size too large. Stack address: 0x7fb7fddf0000, frame address: 0x7fb7fe1ef100, stack size: 4198144, maximum stack size: 8388608 2025.07.28 11:52:59.743970 [ 17207 ] {c88d86d9-1bf7-43f8-8834-04c687184b57} PushingToViews: Failed to push block to view test_5.v1 (4ae2feef-b6fa-47ac-b20c-744da14b2a0a), Stack size too large. Stack address: 0x7fb7fddf0000, frame address: 0x7fb7fe1ef100, stack size: 4198144, maximum stack size: 8388608 2025.07.28 11:52:59.750812 [ 17207 ] {c88d86d9-1bf7-43f8-8834-04c687184b57} PushingToViews: Failed to push block to view test_5.v2 (7c22a887-3ed3-40f1-a092-d92463e4b87b), Stack size too large. Stack address: 0x7fb7fddf0000, frame address: 0x7fb7fe1ef100, stack size: 4198144, maximum stack size: 8388608 2025.07.28 11:52:59.751842 [ 17207 ] {c88d86d9-1bf7-43f8-8834-04c687184b57} PushingToViews: Failed to push block to view test_5.v1 (4ae2feef-b6fa-47ac-b20c-744da14b2a0a), Stack size too large. Stack address: 0x7fb7fddf0000, frame address: 0x7fb7fe1ef100, stack size: 4198144, maximum stack size: 8388608 2025.07.28 11:52:59.754797 [ 17207 ] {c88d86d9-1bf7-43f8-8834-04c687184b57} PushingToViews: Failed to push block to view test_5.v2 (7c22a887-3ed3-40f1-a092-d92463e4b87b), Stack size too large. Stack address: 0x7fb7fddf0000, frame address: 0x7fb7fe1ef100, stack size: 4198144, maximum stack size: 8388608 2025.07.28 11:52:59.757269 [ 17207 ] {c88d86d9-1bf7-43f8-8834-04c687184b57} PushingToViews: Failed to push block to view test_5.v1 (4ae2feef-b6fa-47ac-b20c-744da14b2a0a), Stack size too large. Stack address: 0x7fb7fddf0000, frame address: 0x7fb7fe1ef100, stack size: 4198144, maximum stack size: 8388608 2025.07.28 11:52:59.759977 [ 17207 ] {c88d86d9-1bf7-43f8-8834-04c687184b57} PushingToViews: Failed to push block to view test_5.v2 (7c22a887-3ed3-40f1-a092-d92463e4b87b), Stack size too large. Stack address: 0x7fb7fddf0000, frame address: 0x7fb7fe1ef100, stack size: 4198144, maximum stack size: 8388608 2025.07.28 11:52:59.773731 [ 17207 ] {c88d86d9-1bf7-43f8-8834-04c687184b57} PushingToViews: Failed to push block to view test_5.v1 (4ae2feef-b6fa-47ac-b20c-744da14b2a0a), Stack size too large. Stack address: 0x7fb7fddf0000, frame address: 0x7fb7fe1ef100, stack size: 4198144, maximum stack size: 8388608 2025.07.28 11:52:59.779785 [ 17207 ] {c88d86d9-1bf7-43f8-8834-04c687184b57} PushingToViews: Failed to push block to view test_5.v2 (7c22a887-3ed3-40f1-a092-d92463e4b87b), Stack size too large. Stack address: 0x7fb7fddf0000, frame address: 0x7fb7fe1ef100, stack size: 4198144, maximum stack size: 8388608 2025.07.28 11:52:59.789247 [ 17207 ] {c88d86d9-1bf7-43f8-8834-04c687184b57} PushingToViews: Failed to push block to view test_5.v1 (4ae2feef-b6fa-47ac-b20c-744da14b2a0a), Stack size too large. Stack address: 0x7fb7fddf0000, frame address: 0x7fb7fe1ef100, stack size: 4198144, maximum stack size: 8388608 2025.07.28 11:52:59.801534 [ 17207 ] {c88d86d9-1bf7-43f8-8834-04c687184b57} PushingToViews: Failed to push block to view test_5.v2 (7c22a887-3ed3-40f1-a092-d92463e4b87b), Stack size too large. Stack address: 0x7fb7fddf0000, frame address: 0x7fb7fe1ef100, stack size: 4198144, maximum stack size: 8388608 2025.07.28 11:52:59.803110 [ 17207 ] {c88d86d9-1bf7-43f8-8834-04c687184b57} PushingToViews: Failed to push block to view test_5.v1 (4ae2feef-b6fa-47ac-b20c-744da14b2a0a), Stack size too large. Stack address: 0x7fb7fddf0000, frame address: 0x7fb7fe1ef100, stack size: 4198144, maximum stack size: 8388608 2025.07.28 11:52:59.805189 [ 17207 ] {c88d86d9-1bf7-43f8-8834-04c687184b57} PushingToViews: Failed to push block to view test_5.v2 (7c22a887-3ed3-40f1-a092-d92463e4b87b), Stack size too large. Stack address: 0x7fb7fddf0000, frame address: 0x7fb7fe1ef100, stack size: 4198144, maximum stack size: 8388608 2025.07.28 11:52:59.809417 [ 17207 ] {c88d86d9-1bf7-43f8-8834-04c687184b57} PushingToViews: Failed to push block to view test_5.v1 (4ae2feef-b6fa-47ac-b20c-744da14b2a0a), Stack size too large. Stack address: 0x7fb7fddf0000, frame address: 0x7fb7fe1ef100, stack size: 4198144, maximum stack size: 8388608 2025.07.28 11:52:59.811101 [ 17207 ] {c88d86d9-1bf7-43f8-8834-04c687184b57} PushingToViews: Failed to push block to view test_5.v2 (7c22a887-3ed3-40f1-a092-d92463e4b87b), Stack size too large. Stack address: 0x7fb7fddf0000, frame address: 0x7fb7fe1ef100, stack size: 4198144, maximum stack size: 8388608 2025.07.28 11:52:59.814155 [ 17207 ] {c88d86d9-1bf7-43f8-8834-04c687184b57} PushingToViews: Failed to push block to view test_5.v1 (4ae2feef-b6fa-47ac-b20c-744da14b2a0a), Stack size too large. Stack address: 0x7fb7fddf0000, frame address: 0x7fb7fe1ef100, stack size: 4198144, maximum stack size: 8388608 2025.07.28 11:52:59.817253 [ 17207 ] {c88d86d9-1bf7-43f8-8834-04c687184b57} PushingToViews: Failed to push block to view test_5.v2 (7c22a887-3ed3-40f1-a092-d92463e4b87b), Stack size too large. Stack address: 0x7fb7fddf0000, frame address: 0x7fb7fe1ef100, stack size: 4198144, maximum stack size: 8388608 2025.07.28 11:52:59.820288 [ 17207 ] {c88d86d9-1bf7-43f8-8834-04c687184b57} PushingToViews: Failed to push block to view test_5.v1 (4ae2feef-b6fa-47ac-b20c-744da14b2a0a), Stack size too large. Stack address: 0x7fb7fddf0000, frame address: 0x7fb7fe1ef100, stack size: 4198144, maximum stack size: 8388608 2025.07.28 11:52:59.822316 [ 17207 ] {c88d86d9-1bf7-43f8-8834-04c687184b57} PushingToViews: Failed to push block to view test_5.v2 (7c22a887-3ed3-40f1-a092-d92463e4b87b), Stack size too large. Stack address: 0x7fb7fddf0000, frame address: 0x7fb7fe1ef100, stack size: 4198144, maximum stack size: 8388608 2025.07.28 11:52:59.823642 [ 17207 ] {c88d86d9-1bf7-43f8-8834-04c687184b57} PushingToViews: Failed to push block to view test_5.v1 (4ae2feef-b6fa-47ac-b20c-744da14b2a0a), Stack size too large. Stack address: 0x7fb7fddf0000, frame address: 0x7fb7fe1ef100, stack size: 4198144, maximum stack size: 8388608 2025.07.28 11:52:59.830944 [ 17207 ] {c88d86d9-1bf7-43f8-8834-04c687184b57} PushingToViews: Failed to push block to view test_5.v2 (7c22a887-3ed3-40f1-a092-d92463e4b87b), Stack size too large. Stack address: 0x7fb7fddf0000, frame address: 0x7fb7fe1ef100, stack size: 4198144, maximum stack size: 8388608 2025.07.28 11:52:59.831975 [ 17207 ] {c88d86d9-1bf7-43f8-8834-04c687184b57} PushingToViews: Failed to push block to view test_5.v1 (4ae2feef-b6fa-47ac-b20c-744da14b2a0a), Stack size too large. Stack address: 0x7fb7fddf0000, frame address: 0x7fb7fe1ef100, stack size: 4198144, maximum stack size: 8388608 2025.07.28 11:52:59.834473 [ 17207 ] {c88d86d9-1bf7-43f8-8834-04c687184b57} PushingToViews: Failed to push block to view test_5.v2 (7c22a887-3ed3-40f1-a092-d92463e4b87b), Stack size too large. Stack address: 0x7fb7fddf0000, frame address: 0x7fb7fe1ef100, stack size: 4198144, maximum stack size: 8388608 2025.07.28 11:52:59.835499 [ 17207 ] {c88d86d9-1bf7-43f8-8834-04c687184b57} PushingToViews: Failed to push block to view test_5.v1 (4ae2feef-b6fa-47ac-b20c-744da14b2a0a), Stack size too large. Stack address: 0x7fb7fddf0000, frame address: 0x7fb7fe1ef100, stack size: 4198144, maximum stack size: 8388608 2025.07.28 11:52:59.836779 [ 17207 ] {c88d86d9-1bf7-43f8-8834-04c687184b57} PushingToViews: Failed to push block to view test_5.v2 (7c22a887-3ed3-40f1-a092-d92463e4b87b), Stack size too large. Stack address: 0x7fb7fddf0000, frame address: 0x7fb7fe1ef100, stack size: 4198144, maximum stack size: 8388608 2025.07.28 11:52:59.838501 [ 17207 ] {c88d86d9-1bf7-43f8-8834-04c687184b57} PushingToViews: Failed to push block to view test_5.v1 (4ae2feef-b6fa-47ac-b20c-744da14b2a0a), Stack size too large. Stack address: 0x7fb7fddf0000, frame address: 0x7fb7fe1ef100, stack size: 4198144, maximum stack size: 8388608 2025.07.28 11:52:59.839754 [ 17207 ] {c88d86d9-1bf7-43f8-8834-04c687184b57} PushingToViews: Failed to push block to view test_5.v2 (7c22a887-3ed3-40f1-a092-d92463e4b87b), Stack size too large. Stack address: 0x7fb7fddf0000, frame address: 0x7fb7fe1ef100, stack size: 4198144, maximum stack size: 8388608 2025.07.28 11:52:59.841530 [ 17207 ] {c88d86d9-1bf7-43f8-8834-04c687184b57} PushingToViews: Failed to push block to view test_5.v1 (4ae2feef-b6fa-47ac-b20c-744da14b2a0a), Stack size too large. Stack address: 0x7fb7fddf0000, frame address: 0x7fb7fe1ef100, stack size: 4198144, maximum stack size: 8388608 2025.07.28 11:52:59.843809 [ 17207 ] {c88d86d9-1bf7-43f8-8834-04c687184b57} PushingToViews: Failed to push block to view test_5.v2 (7c22a887-3ed3-40f1-a092-d92463e4b87b), Stack size too large. Stack address: 0x7fb7fddf0000, frame address: 0x7fb7fe1ef100, stack size: 4198144, maximum stack size: 8388608 2025.07.28 11:52:59.861805 [ 17207 ] {c88d86d9-1bf7-43f8-8834-04c687184b57} PushingToViews: Failed to push block to view test_5.v1 (4ae2feef-b6fa-47ac-b20c-744da14b2a0a), Stack size too large. Stack address: 0x7fb7fddf0000, frame address: 0x7fb7fe1ef100, stack size: 4198144, maximum stack size: 8388608 2025.07.28 11:52:59.865613 [ 17207 ] {c88d86d9-1bf7-43f8-8834-04c687184b57} PushingToViews: Failed to push block to view test_5.v2 (7c22a887-3ed3-40f1-a092-d92463e4b87b), Stack size too large. Stack address: 0x7fb7fddf0000, frame address: 0x7fb7fe1ef100, stack size: 4198144, maximum stack size: 8388608 2025.07.28 11:52:59.874584 [ 17207 ] {c88d86d9-1bf7-43f8-8834-04c687184b57} PushingToViews: Failed to push block to view test_5.v1 (4ae2feef-b6fa-47ac-b20c-744da14b2a0a), Stack size too large. Stack address: 0x7fb7fddf0000, frame address: 0x7fb7fe1ef100, stack size: 4198144, maximum stack size: 8388608 2025.07.28 11:52:59.876212 [ 17207 ] {c88d86d9-1bf7-43f8-8834-04c687184b57} PushingToViews: Failed to push block to view test_5.v2 (7c22a887-3ed3-40f1-a092-d92463e4b87b), Stack size too large. Stack address: 0x7fb7fddf0000, frame address: 0x7fb7fe1ef100, stack size: 4198144, maximum stack size: 8388608 2025.07.28 11:52:59.877234 [ 17207 ] {c88d86d9-1bf7-43f8-8834-04c687184b57} PushingToViews: Failed to push block to view test_5.v1 (4ae2feef-b6fa-47ac-b20c-744da14b2a0a), Stack size too large. Stack address: 0x7fb7fddf0000, frame address: 0x7fb7fe1ef100, stack size: 4198144, maximum stack size: 8388608 2025.07.28 11:52:59.878854 [ 17207 ] {c88d86d9-1bf7-43f8-8834-04c687184b57} PushingToViews: Failed to push block to view test_5.v2 (7c22a887-3ed3-40f1-a092-d92463e4b87b), Stack size too large. Stack address: 0x7fb7fddf0000, frame address: 0x7fb7fe1ef100, stack size: 4198144, maximum stack size: 8388608 2025.07.28 11:52:59.881611 [ 17207 ] {c88d86d9-1bf7-43f8-8834-04c687184b57} PushingToViews: Failed to push block to view test_5.v1 (4ae2feef-b6fa-47ac-b20c-744da14b2a0a), Stack size too large. Stack address: 0x7fb7fddf0000, frame address: 0x7fb7fe1ef100, stack size: 4198144, maximum stack size: 8388608 2025.07.28 11:52:59.883228 [ 17207 ] {c88d86d9-1bf7-43f8-8834-04c687184b57} PushingToViews: Failed to push block to view test_5.v2 (7c22a887-3ed3-40f1-a092-d92463e4b87b), Stack size too large. Stack address: 0x7fb7fddf0000, frame address: 0x7fb7fe1ef100, stack size: 4198144, maximum stack size: 8388608 2025.07.28 11:52:59.885387 [ 17207 ] {c88d86d9-1bf7-43f8-8834-04c687184b57} PushingToViews: Failed to push block to view test_5.v1 (4ae2feef-b6fa-47ac-b20c-744da14b2a0a), Stack size too large. Stack address: 0x7fb7fddf0000, frame address: 0x7fb7fe1ef100, stack size: 4198144, maximum stack size: 8388608 2025.07.28 11:52:59.888097 [ 17207 ] {c88d86d9-1bf7-43f8-8834-04c687184b57} PushingToViews: Failed to push block to view test_5.v2 (7c22a887-3ed3-40f1-a092-d92463e4b87b), Stack size too large. Stack address: 0x7fb7fddf0000, frame address: 0x7fb7fe1ef100, stack size: 4198144, maximum stack size: 8388608 2025.07.28 11:52:59.893487 [ 17207 ] {c88d86d9-1bf7-43f8-8834-04c687184b57} PushingToViews: Failed to push block to view test_5.v1 (4ae2feef-b6fa-47ac-b20c-744da14b2a0a), Stack size too large. Stack address: 0x7fb7fddf0000, frame address: 0x7fb7fe1ef100, stack size: 4198144, maximum stack size: 8388608 2025.07.28 11:52:59.894669 [ 17207 ] {c88d86d9-1bf7-43f8-8834-04c687184b57} PushingToViews: Failed to push block to view test_5.v2 (7c22a887-3ed3-40f1-a092-d92463e4b87b), Stack size too large. Stack address: 0x7fb7fddf0000, frame address: 0x7fb7fe1ef100, stack size: 4198144, maximum stack size: 8388608 2025.07.28 11:52:59.895682 [ 17207 ] {c88d86d9-1bf7-43f8-8834-04c687184b57} PushingToViews: Failed to push block to view test_5.v1 (4ae2feef-b6fa-47ac-b20c-744da14b2a0a), Stack size too large. Stack address: 0x7fb7fddf0000, frame address: 0x7fb7fe1ef100, stack size: 4198144, maximum stack size: 8388608 2025.07.28 11:52:59.897956 [ 17207 ] {c88d86d9-1bf7-43f8-8834-04c687184b57} PushingToViews: Failed to push block to view test_5.v2 (7c22a887-3ed3-40f1-a092-d92463e4b87b), Stack size too large. Stack address: 0x7fb7fddf0000, frame address: 0x7fb7fe1ef100, stack size: 4198144, maximum stack size: 8388608 2025.07.28 11:52:59.899113 [ 17207 ] {c88d86d9-1bf7-43f8-8834-04c687184b57} PushingToViews: Failed to push block to view test_5.v1 (4ae2feef-b6fa-47ac-b20c-744da14b2a0a), Stack size too large. Stack address: 0x7fb7fddf0000, frame address: 0x7fb7fe1ef100, stack size: 4198144, maximum stack size: 8388608 2025.07.28 11:52:59.900037 [ 17207 ] {c88d86d9-1bf7-43f8-8834-04c687184b57} PushingToViews: Failed to push block to view test_5.v2 (7c22a887-3ed3-40f1-a092-d92463e4b87b), Stack size too large. Stack address: 0x7fb7fddf0000, frame address: 0x7fb7fe1ef100, stack size: 4198144, maximum stack size: 8388608 2025.07.28 11:52:59.902055 [ 17207 ] {c88d86d9-1bf7-43f8-8834-04c687184b57} PushingToViews: Failed to push block to view test_5.v1 (4ae2feef-b6fa-47ac-b20c-744da14b2a0a), Stack size too large. Stack address: 0x7fb7fddf0000, frame address: 0x7fb7fe1ef100, stack size: 4198144, maximum stack size: 8388608 2025.07.28 11:52:59.904930 [ 17207 ] {c88d86d9-1bf7-43f8-8834-04c687184b57} PushingToViews: Failed to push block to view test_5.v2 (7c22a887-3ed3-40f1-a092-d92463e4b87b), Stack size too large. Stack address: 0x7fb7fddf0000, frame address: 0x7fb7fe1ef100, stack size: 4198144, maximum stack size: 8388608 2025.07.28 11:52:59.915413 [ 17207 ] {c88d86d9-1bf7-43f8-8834-04c687184b57} PushingToViews: Failed to push block to view test_5.v1 (4ae2feef-b6fa-47ac-b20c-744da14b2a0a), Stack size too large. Stack address: 0x7fb7fddf0000, frame address: 0x7fb7fe1ef100, stack size: 4198144, maximum stack size: 8388608 2025.07.28 11:52:59.916547 [ 17207 ] {c88d86d9-1bf7-43f8-8834-04c687184b57} PushingToViews: Failed to push block to view test_5.v2 (7c22a887-3ed3-40f1-a092-d92463e4b87b), Stack size too large. Stack address: 0x7fb7fddf0000, frame address: 0x7fb7fe1ef100, stack size: 4198144, maximum stack size: 8388608 2025.07.28 11:52:59.927238 [ 17207 ] {c88d86d9-1bf7-43f8-8834-04c687184b57} PushingToViews: Failed to push block to view test_5.v1 (4ae2feef-b6fa-47ac-b20c-744da14b2a0a), Stack size too large. Stack address: 0x7fb7fddf0000, frame address: 0x7fb7fe1ef100, stack size: 4198144, maximum stack size: 8388608 2025.07.28 11:52:59.928594 [ 17207 ] {c88d86d9-1bf7-43f8-8834-04c687184b57} PushingToViews: Failed to push block to view test_5.v2 (7c22a887-3ed3-40f1-a092-d92463e4b87b), Stack size too large. Stack address: 0x7fb7fddf0000, frame address: 0x7fb7fe1ef100, stack size: 4198144, maximum stack size: 8388608 2025.07.28 11:52:59.930493 [ 17207 ] {c88d86d9-1bf7-43f8-8834-04c687184b57} PushingToViews: Failed to push block to view test_5.v1 (4ae2feef-b6fa-47ac-b20c-744da14b2a0a), Stack size too large. Stack address: 0x7fb7fddf0000, frame address: 0x7fb7fe1ef100, stack size: 4198144, maximum stack size: 8388608 2025.07.28 11:52:59.931776 [ 17207 ] {c88d86d9-1bf7-43f8-8834-04c687184b57} PushingToViews: Failed to push block to view test_5.v2 (7c22a887-3ed3-40f1-a092-d92463e4b87b), Stack size too large. Stack address: 0x7fb7fddf0000, frame address: 0x7fb7fe1ef100, stack size: 4198144, maximum stack size: 8388608 2025.07.28 11:52:59.940830 [ 17207 ] {c88d86d9-1bf7-43f8-8834-04c687184b57} PushingToViews: Failed to push block to view test_5.v1 (4ae2feef-b6fa-47ac-b20c-744da14b2a0a), Stack size too large. Stack address: 0x7fb7fddf0000, frame address: 0x7fb7fe1ef100, stack size: 4198144, maximum stack size: 8388608 2025.07.28 11:52:59.944322 [ 17207 ] {c88d86d9-1bf7-43f8-8834-04c687184b57} PushingToViews: Failed to push block to view test_5.v2 (7c22a887-3ed3-40f1-a092-d92463e4b87b), Stack size too large. Stack address: 0x7fb7fddf0000, frame address: 0x7fb7fe1ef100, stack size: 4198144, maximum stack size: 8388608 2025.07.28 11:52:59.946424 [ 17207 ] {c88d86d9-1bf7-43f8-8834-04c687184b57} PushingToViews: Failed to push block to view test_5.v1 (4ae2feef-b6fa-47ac-b20c-744da14b2a0a), Stack size too large. Stack address: 0x7fb7fddf0000, frame address: 0x7fb7fe1ef100, stack size: 4198144, maximum stack size: 8388608 2025.07.28 11:53:00.047662 [ 17207 ] {c88d86d9-1bf7-43f8-8834-04c687184b57} PushingToViews: Failed to push block to view test_5.v2 (7c22a887-3ed3-40f1-a092-d92463e4b87b), Stack size too large. Stack address: 0x7fb7fddf0000, frame address: 0x7fb7fe1ef100, stack size: 4198144, maximum stack size: 8388608 2025.07.28 11:53:00.049877 [ 17207 ] {c88d86d9-1bf7-43f8-8834-04c687184b57} PushingToViews: Failed to push block to view test_5.v1 (4ae2feef-b6fa-47ac-b20c-744da14b2a0a), Stack size too large. Stack address: 0x7fb7fddf0000, frame address: 0x7fb7fe1ef100, stack size: 4198144, maximum stack size: 8388608 2025.07.28 11:53:00.053895 [ 17207 ] {c88d86d9-1bf7-43f8-8834-04c687184b57} PushingToViews: Failed to push block to view test_5.v2 (7c22a887-3ed3-40f1-a092-d92463e4b87b), Stack size too large. Stack address: 0x7fb7fddf0000, frame address: 0x7fb7fe1ef100, stack size: 4198144, maximum stack size: 8388608 2025.07.28 11:53:00.063085 [ 17207 ] {c88d86d9-1bf7-43f8-8834-04c687184b57} PushingToViews: Failed to push block to view test_5.v1 (4ae2feef-b6fa-47ac-b20c-744da14b2a0a), Stack size too large. Stack address: 0x7fb7fddf0000, frame address: 0x7fb7fe1ef100, stack size: 4198144, maximum stack size: 8388608 2025.07.28 11:53:00.069205 [ 17207 ] {c88d86d9-1bf7-43f8-8834-04c687184b57} PushingToViews: Failed to push block to view test_5.v2 (7c22a887-3ed3-40f1-a092-d92463e4b87b), Stack size too large. Stack address: 0x7fb7fddf0000, frame address: 0x7fb7fe1ef100, stack size: 4198144, maximum stack size: 8388608 2025.07.28 11:53:00.072397 [ 17207 ] {c88d86d9-1bf7-43f8-8834-04c687184b57} PushingToViews: Failed to push block to view test_5.v1 (4ae2feef-b6fa-47ac-b20c-744da14b2a0a), Stack size too large. Stack address: 0x7fb7fddf0000, frame address: 0x7fb7fe1ef100, stack size: 4198144, maximum stack size: 8388608 2025.07.28 11:53:00.074077 [ 17207 ] {c88d86d9-1bf7-43f8-8834-04c687184b57} PushingToViews: Failed to push block to view test_5.v2 (7c22a887-3ed3-40f1-a092-d92463e4b87b), Stack size too large. Stack address: 0x7fb7fddf0000, frame address: 0x7fb7fe1ef100, stack size: 4198144, maximum stack size: 8388608 2025.07.28 11:53:00.075786 [ 17207 ] {c88d86d9-1bf7-43f8-8834-04c687184b57} PushingToViews: Failed to push block to view test_5.v1 (4ae2feef-b6fa-47ac-b20c-744da14b2a0a), Stack size too large. Stack address: 0x7fb7fddf0000, frame address: 0x7fb7fe1ef100, stack size: 4198144, maximum stack size: 8388608 2025.07.28 11:53:00.083056 [ 17207 ] {c88d86d9-1bf7-43f8-8834-04c687184b57} PushingToViews: Failed to push block to view test_5.v2 (7c22a887-3ed3-40f1-a092-d92463e4b87b), Stack size too large. Stack address: 0x7fb7fddf0000, frame address: 0x7fb7fe1ef100, stack size: 4198144, maximum stack size: 8388608 2025.07.28 11:53:00.100439 [ 17207 ] {c88d86d9-1bf7-43f8-8834-04c687184b57} PushingToViews: Failed to push block to view test_5.v1 (4ae2feef-b6fa-47ac-b20c-744da14b2a0a), Stack size too large. Stack address: 0x7fb7fddf0000, frame address: 0x7fb7fe1ef100, stack size: 4198144, maximum stack size: 8388608 2025.07.28 11:53:00.112060 [ 17207 ] {c88d86d9-1bf7-43f8-8834-04c687184b57} PushingToViews: Failed to push block to view test_5.v2 (7c22a887-3ed3-40f1-a092-d92463e4b87b), Stack size too large. Stack address: 0x7fb7fddf0000, frame address: 0x7fb7fe1ef100, stack size: 4198144, maximum stack size: 8388608 2025.07.28 11:53:00.125995 [ 17207 ] {c88d86d9-1bf7-43f8-8834-04c687184b57} PushingToViews: Failed to push block to view test_5.v1 (4ae2feef-b6fa-47ac-b20c-744da14b2a0a), Stack size too large. Stack address: 0x7fb7fddf0000, frame address: 0x7fb7fe1ef100, stack size: 4198144, maximum stack size: 8388608 2025.07.28 11:53:00.129525 [ 17207 ] {c88d86d9-1bf7-43f8-8834-04c687184b57} PushingToViews: Failed to push block to view test_5.v2 (7c22a887-3ed3-40f1-a092-d92463e4b87b), Stack size too large. Stack address: 0x7fb7fddf0000, frame address: 0x7fb7fe1ef100, stack size: 4198144, maximum stack size: 8388608 2025.07.28 11:53:00.134014 [ 17207 ] {c88d86d9-1bf7-43f8-8834-04c687184b57} PushingToViews: Failed to push block to view test_5.v1 (4ae2feef-b6fa-47ac-b20c-744da14b2a0a), Stack size too large. Stack address: 0x7fb7fddf0000, frame address: 0x7fb7fe1ef100, stack size: 4198144, maximum stack size: 8388608 2025.07.28 11:53:00.147787 [ 17207 ] {c88d86d9-1bf7-43f8-8834-04c687184b57} PushingToViews: Failed to push block to view test_5.v2 (7c22a887-3ed3-40f1-a092-d92463e4b87b), Stack size too large. Stack address: 0x7fb7fddf0000, frame address: 0x7fb7fe1ef100, stack size: 4198144, maximum stack size: 8388608 2025.07.28 11:53:00.151281 [ 17207 ] {c88d86d9-1bf7-43f8-8834-04c687184b57} PushingToViews: Failed to push block to view test_5.v1 (4ae2feef-b6fa-47ac-b20c-744da14b2a0a), Stack size too large. Stack address: 0x7fb7fddf0000, frame address: 0x7fb7fe1ef100, stack size: 4198144, maximum stack size: 8388608 2025.07.28 11:53:00.155845 [ 17207 ] {c88d86d9-1bf7-43f8-8834-04c687184b57} PushingToViews: Failed to push block to view test_5.v2 (7c22a887-3ed3-40f1-a092-d92463e4b87b), Stack size too large. Stack address: 0x7fb7fddf0000, frame address: 0x7fb7fe1ef100, stack size: 4198144, maximum stack size: 8388608 2025.07.28 11:53:00.175952 [ 17207 ] {c88d86d9-1bf7-43f8-8834-04c687184b57} PushingToViews: Failed to push block to view test_5.v1 (4ae2feef-b6fa-47ac-b20c-744da14b2a0a), Stack size too large. Stack address: 0x7fb7fddf0000, frame address: 0x7fb7fe1ef100, stack size: 4198144, maximum stack size: 8388608 2025.07.28 11:53:00.183790 [ 17207 ] {c88d86d9-1bf7-43f8-8834-04c687184b57} PushingToViews: Failed to push block to view test_5.v2 (7c22a887-3ed3-40f1-a092-d92463e4b87b), Stack size too large. Stack address: 0x7fb7fddf0000, frame address: 0x7fb7fe1ef100, stack size: 4198144, maximum stack size: 8388608 2025.07.28 11:53:00.192890 [ 17207 ] {c88d86d9-1bf7-43f8-8834-04c687184b57} PushingToViews: Failed to push block to view test_5.v1 (4ae2feef-b6fa-47ac-b20c-744da14b2a0a), Stack size too large. Stack address: 0x7fb7fddf0000, frame address: 0x7fb7fe1ef100, stack size: 4198144, maximum stack size: 8388608 2025.07.28 11:53:00.197311 [ 17207 ] {c88d86d9-1bf7-43f8-8834-04c687184b57} PushingToViews: Failed to push block to view test_5.v2 (7c22a887-3ed3-40f1-a092-d92463e4b87b), Stack size too large. Stack address: 0x7fb7fddf0000, frame address: 0x7fb7fe1ef100, stack size: 4198144, maximum stack size: 8388608 2025.07.28 11:53:00.200710 [ 17207 ] {c88d86d9-1bf7-43f8-8834-04c687184b57} PushingToViews: Failed to push block to view test_5.v1 (4ae2feef-b6fa-47ac-b20c-744da14b2a0a), Stack size too large. Stack address: 0x7fb7fddf0000, frame address: 0x7fb7fe1ef100, stack size: 4198144, maximum stack size: 8388608 2025.07.28 11:53:00.204053 [ 17207 ] {c88d86d9-1bf7-43f8-8834-04c687184b57} PushingToViews: Failed to push block to view test_5.v2 (7c22a887-3ed3-40f1-a092-d92463e4b87b), Stack size too large. Stack address: 0x7fb7fddf0000, frame address: 0x7fb7fe1ef100, stack size: 4198144, maximum stack size: 8388608 2025.07.28 11:53:00.208881 [ 17207 ] {c88d86d9-1bf7-43f8-8834-04c687184b57} PushingToViews: Failed to push block to view test_5.v1 (4ae2feef-b6fa-47ac-b20c-744da14b2a0a), Stack size too large. Stack address: 0x7fb7fddf0000, frame address: 0x7fb7fe1ef100, stack size: 4198144, maximum stack size: 8388608 2025.07.28 11:53:00.211571 [ 17207 ] {c88d86d9-1bf7-43f8-8834-04c687184b57} PushingToViews: Failed to push block to view test_5.v2 (7c22a887-3ed3-40f1-a092-d92463e4b87b), Stack size too large. Stack address: 0x7fb7fddf0000, frame address: 0x7fb7fe1ef100, stack size: 4198144, maximum stack size: 8388608 2025.07.28 11:53:00.214089 [ 17207 ] {c88d86d9-1bf7-43f8-8834-04c687184b57} PushingToViews: Failed to push block to view test_5.v1 (4ae2feef-b6fa-47ac-b20c-744da14b2a0a), Stack size too large. Stack address: 0x7fb7fddf0000, frame address: 0x7fb7fe1ef100, stack size: 4198144, maximum stack size: 8388608 2025.07.28 11:53:00.216373 [ 17207 ] {c88d86d9-1bf7-43f8-8834-04c687184b57} PushingToViews: Failed to push block to view test_5.v2 (7c22a887-3ed3-40f1-a092-d92463e4b87b), Stack size too large. Stack address: 0x7fb7fddf0000, frame address: 0x7fb7fe1ef100, stack size: 4198144, maximum stack size: 8388608 2025.07.28 11:53:00.225259 [ 17207 ] {c88d86d9-1bf7-43f8-8834-04c687184b57} PushingToViews: Failed to push block to view test_5.v1 (4ae2feef-b6fa-47ac-b20c-744da14b2a0a), Stack size too large. Stack address: 0x7fb7fddf0000, frame address: 0x7fb7fe1ef100, stack size: 4198144, maximum stack size: 8388608 2025.07.28 11:53:00.230298 [ 17207 ] {c88d86d9-1bf7-43f8-8834-04c687184b57} PushingToViews: Failed to push block to view test_5.v2 (7c22a887-3ed3-40f1-a092-d92463e4b87b), Stack size too large. Stack address: 0x7fb7fddf0000, frame address: 0x7fb7fe1ef100, stack size: 4198144, maximum stack size: 8388608 2025.07.28 11:53:00.247021 [ 17207 ] {c88d86d9-1bf7-43f8-8834-04c687184b57} PushingToViews: Failed to push block to view test_5.v1 (4ae2feef-b6fa-47ac-b20c-744da14b2a0a), Stack size too large. Stack address: 0x7fb7fddf0000, frame address: 0x7fb7fe1ef100, stack size: 4198144, maximum stack size: 8388608 2025.07.28 11:53:00.248035 [ 17207 ] {c88d86d9-1bf7-43f8-8834-04c687184b57} PushingToViews: Failed to push block to view test_5.v2 (7c22a887-3ed3-40f1-a092-d92463e4b87b), Stack size too large. Stack address: 0x7fb7fddf0000, frame address: 0x7fb7fe1ef100, stack size: 4198144, maximum stack size: 8388608 2025.07.28 11:53:00.249187 [ 17207 ] {c88d86d9-1bf7-43f8-8834-04c687184b57} PushingToViews: Failed to push block to view test_5.v1 (4ae2feef-b6fa-47ac-b20c-744da14b2a0a), Stack size too large. Stack address: 0x7fb7fddf0000, frame address: 0x7fb7fe1ef100, stack size: 4198144, maximum stack size: 8388608 2025.07.28 11:53:00.256442 [ 17207 ] {c88d86d9-1bf7-43f8-8834-04c687184b57} PushingToViews: Failed to push block to view test_5.v2 (7c22a887-3ed3-40f1-a092-d92463e4b87b), Stack size too large. Stack address: 0x7fb7fddf0000, frame address: 0x7fb7fe1ef100, stack size: 4198144, maximum stack size: 8388608 2025.07.28 11:53:00.260996 [ 17207 ] {c88d86d9-1bf7-43f8-8834-04c687184b57} PushingToViews: Failed to push block to view test_5.v1 (4ae2feef-b6fa-47ac-b20c-744da14b2a0a), Stack size too large. Stack address: 0x7fb7fddf0000, frame address: 0x7fb7fe1ef100, stack size: 4198144, maximum stack size: 8388608 2025.07.28 11:53:00.268507 [ 17207 ] {c88d86d9-1bf7-43f8-8834-04c687184b57} PushingToViews: Failed to push block to view test_5.v2 (7c22a887-3ed3-40f1-a092-d92463e4b87b), Stack size too large. Stack address: 0x7fb7fddf0000, frame address: 0x7fb7fe1ef100, stack size: 4198144, maximum stack size: 8388608 2025.07.28 11:53:00.292033 [ 17207 ] {c88d86d9-1bf7-43f8-8834-04c687184b57} PushingToViews: Failed to push block to view test_5.v1 (4ae2feef-b6fa-47ac-b20c-744da14b2a0a), Stack size too large. Stack address: 0x7fb7fddf0000, frame address: 0x7fb7fe1ef100, stack size: 4198144, maximum stack size: 8388608 2025.07.28 11:53:00.308926 [ 17207 ] {c88d86d9-1bf7-43f8-8834-04c687184b57} PushingToViews: Failed to push block to view test_5.v2 (7c22a887-3ed3-40f1-a092-d92463e4b87b), Stack size too large. Stack address: 0x7fb7fddf0000, frame address: 0x7fb7fe1ef100, stack size: 4198144, maximum stack size: 8388608 2025.07.28 11:53:00.316601 [ 17207 ] {c88d86d9-1bf7-43f8-8834-04c687184b57} PushingToViews: Failed to push block to view test_5.v1 (4ae2feef-b6fa-47ac-b20c-744da14b2a0a), Stack size too large. Stack address: 0x7fb7fddf0000, frame address: 0x7fb7fe1ef100, stack size: 4198144, maximum stack size: 8388608 2025.07.28 11:53:00.318947 [ 17207 ] {c88d86d9-1bf7-43f8-8834-04c687184b57} PushingToViews: Failed to push block to view test_5.v2 (7c22a887-3ed3-40f1-a092-d92463e4b87b), Stack size too large. Stack address: 0x7fb7fddf0000, frame address: 0x7fb7fe1ef100, stack size: 4198144, maximum stack size: 8388608 2025.07.28 11:53:00.321951 [ 17207 ] {c88d86d9-1bf7-43f8-8834-04c687184b57} PushingToViews: Failed to push block to view test_5.v1 (4ae2feef-b6fa-47ac-b20c-744da14b2a0a), Stack size too large. Stack address: 0x7fb7fddf0000, frame address: 0x7fb7fe1ef100, stack size: 4198144, maximum stack size: 8388608 2025.07.28 11:53:00.323165 [ 17207 ] {c88d86d9-1bf7-43f8-8834-04c687184b57} PushingToViews: Failed to push block to view test_5.v2 (7c22a887-3ed3-40f1-a092-d92463e4b87b), Stack size too large. Stack address: 0x7fb7fddf0000, frame address: 0x7fb7fe1ef100, stack size: 4198144, maximum stack size: 8388608 2025.07.28 11:53:00.325915 [ 17207 ] {c88d86d9-1bf7-43f8-8834-04c687184b57} PushingToViews: Failed to push block to view test_5.v1 (4ae2feef-b6fa-47ac-b20c-744da14b2a0a), Stack size too large. Stack address: 0x7fb7fddf0000, frame address: 0x7fb7fe1ef100, stack size: 4198144, maximum stack size: 8388608 2025.07.28 11:53:00.329047 [ 17207 ] {c88d86d9-1bf7-43f8-8834-04c687184b57} PushingToViews: Failed to push block to view test_5.v2 (7c22a887-3ed3-40f1-a092-d92463e4b87b), Stack size too large. Stack address: 0x7fb7fddf0000, frame address: 0x7fb7fe1ef100, stack size: 4198144, maximum stack size: 8388608 2025.07.28 11:53:00.329819 [ 17207 ] {c88d86d9-1bf7-43f8-8834-04c687184b57} PushingToViews: Failed to push block to view test_5.v1 (4ae2feef-b6fa-47ac-b20c-744da14b2a0a), Stack size too large. Stack address: 0x7fb7fddf0000, frame address: 0x7fb7fe1ef100, stack size: 4198144, maximum stack size: 8388608 2025.07.28 11:53:00.331416 [ 17207 ] {c88d86d9-1bf7-43f8-8834-04c687184b57} PushingToViews: Failed to push block to view test_5.v2 (7c22a887-3ed3-40f1-a092-d92463e4b87b), Stack size too large. Stack address: 0x7fb7fddf0000, frame address: 0x7fb7fe1ef100, stack size: 4198144, maximum stack size: 8388608 2025.07.28 11:53:00.332941 [ 17207 ] {c88d86d9-1bf7-43f8-8834-04c687184b57} PushingToViews: Failed to push block to view test_5.v1 (4ae2feef-b6fa-47ac-b20c-744da14b2a0a), Stack size too large. Stack address: 0x7fb7fddf0000, frame address: 0x7fb7fe1ef100, stack size: 4198144, maximum stack size: 8388608 2025.07.28 11:53:00.334136 [ 17207 ] {c88d86d9-1bf7-43f8-8834-04c687184b57} PushingToViews: Failed to push block to view test_5.v2 (7c22a887-3ed3-40f1-a092-d92463e4b87b), Stack size too large. Stack address: 0x7fb7fddf0000, frame address: 0x7fb7fe1ef100, stack size: 4198144, maximum stack size: 8388608 2025.07.28 11:53:00.350976 [ 17207 ] {c88d86d9-1bf7-43f8-8834-04c687184b57} PushingToViews: Failed to push block to view test_5.v1 (4ae2feef-b6fa-47ac-b20c-744da14b2a0a), Stack size too large. Stack address: 0x7fb7fddf0000, frame address: 0x7fb7fe1ef100, stack size: 4198144, maximum stack size: 8388608 2025.07.28 11:53:00.353373 [ 17207 ] {c88d86d9-1bf7-43f8-8834-04c687184b57} PushingToViews: Failed to push block to view test_5.v2 (7c22a887-3ed3-40f1-a092-d92463e4b87b), Stack size too large. Stack address: 0x7fb7fddf0000, frame address: 0x7fb7fe1ef100, stack size: 4198144, maximum stack size: 8388608 2025.07.28 11:53:00.354871 [ 17207 ] {c88d86d9-1bf7-43f8-8834-04c687184b57} PushingToViews: Failed to push block to view test_5.v1 (4ae2feef-b6fa-47ac-b20c-744da14b2a0a), Stack size too large. Stack address: 0x7fb7fddf0000, frame address: 0x7fb7fe1ef100, stack size: 4198144, maximum stack size: 8388608 2025.07.28 11:53:00.359855 [ 17207 ] {c88d86d9-1bf7-43f8-8834-04c687184b57} PushingToViews: Failed to push block to view test_5.v2 (7c22a887-3ed3-40f1-a092-d92463e4b87b), Stack size too large. Stack address: 0x7fb7fddf0000, frame address: 0x7fb7fe1ef100, stack size: 4198144, maximum stack size: 8388608 2025.07.28 11:53:00.372672 [ 17207 ] {c88d86d9-1bf7-43f8-8834-04c687184b57} PushingToViews: Failed to push block to view test_5.v1 (4ae2feef-b6fa-47ac-b20c-744da14b2a0a), Stack size too large. Stack address: 0x7fb7fddf0000, frame address: 0x7fb7fe1ef100, stack size: 4198144, maximum stack size: 8388608 2025.07.28 11:53:00.374437 [ 17207 ] {c88d86d9-1bf7-43f8-8834-04c687184b57} PushingToViews: Failed to push block to view test_5.v2 (7c22a887-3ed3-40f1-a092-d92463e4b87b), Stack size too large. Stack address: 0x7fb7fddf0000, frame address: 0x7fb7fe1ef100, stack size: 4198144, maximum stack size: 8388608 2025.07.28 11:53:00.375627 [ 17207 ] {c88d86d9-1bf7-43f8-8834-04c687184b57} PushingToViews: Failed to push block to view test_5.v1 (4ae2feef-b6fa-47ac-b20c-744da14b2a0a), Stack size too large. Stack address: 0x7fb7fddf0000, frame address: 0x7fb7fe1ef100, stack size: 4198144, maximum stack size: 8388608 2025.07.28 11:53:00.376982 [ 17207 ] {c88d86d9-1bf7-43f8-8834-04c687184b57} PushingToViews: Failed to push block to view test_5.v2 (7c22a887-3ed3-40f1-a092-d92463e4b87b), Stack size too large. Stack address: 0x7fb7fddf0000, frame address: 0x7fb7fe1ef100, stack size: 4198144, maximum stack size: 8388608 2025.07.28 11:53:00.378112 [ 17207 ] {c88d86d9-1bf7-43f8-8834-04c687184b57} PushingToViews: Failed to push block to view test_5.v1 (4ae2feef-b6fa-47ac-b20c-744da14b2a0a), Stack size too large. Stack address: 0x7fb7fddf0000, frame address: 0x7fb7fe1ef100, stack size: 4198144, maximum stack size: 8388608 2025.07.28 11:53:00.379246 [ 17207 ] {c88d86d9-1bf7-43f8-8834-04c687184b57} PushingToViews: Failed to push block to view test_5.v2 (7c22a887-3ed3-40f1-a092-d92463e4b87b), Stack size too large. Stack address: 0x7fb7fddf0000, frame address: 0x7fb7fe1ef100, stack size: 4198144, maximum stack size: 8388608 2025.07.28 11:53:00.385697 [ 17207 ] {c88d86d9-1bf7-43f8-8834-04c687184b57} PushingToViews: Failed to push block to view test_5.v1 (4ae2feef-b6fa-47ac-b20c-744da14b2a0a), Stack size too large. Stack address: 0x7fb7fddf0000, frame address: 0x7fb7fe1ef100, stack size: 4198144, maximum stack size: 8388608 2025.07.28 11:53:00.389379 [ 17207 ] {c88d86d9-1bf7-43f8-8834-04c687184b57} PushingToViews: Failed to push block to view test_5.v2 (7c22a887-3ed3-40f1-a092-d92463e4b87b), Stack size too large. Stack address: 0x7fb7fddf0000, frame address: 0x7fb7fe1ef100, stack size: 4198144, maximum stack size: 8388608 2025.07.28 11:53:00.392257 [ 17207 ] {c88d86d9-1bf7-43f8-8834-04c687184b57} PushingToViews: Failed to push block to view test_5.v1 (4ae2feef-b6fa-47ac-b20c-744da14b2a0a), Stack size too large. Stack address: 0x7fb7fddf0000, frame address: 0x7fb7fe1ef100, stack size: 4198144, maximum stack size: 8388608 2025.07.28 11:53:00.394030 [ 17207 ] {c88d86d9-1bf7-43f8-8834-04c687184b57} PushingToViews: Failed to push block to view test_5.v2 (7c22a887-3ed3-40f1-a092-d92463e4b87b), Stack size too large. Stack address: 0x7fb7fddf0000, frame address: 0x7fb7fe1ef100, stack size: 4198144, maximum stack size: 8388608 2025.07.28 11:53:00.403065 [ 17207 ] {c88d86d9-1bf7-43f8-8834-04c687184b57} PushingToViews: Failed to push block to view test_5.v1 (4ae2feef-b6fa-47ac-b20c-744da14b2a0a), Stack size too large. Stack address: 0x7fb7fddf0000, frame address: 0x7fb7fe1ef100, stack size: 4198144, maximum stack size: 8388608 2025.07.28 11:53:00.404086 [ 17207 ] {c88d86d9-1bf7-43f8-8834-04c687184b57} PushingToViews: Failed to push block to view test_5.v2 (7c22a887-3ed3-40f1-a092-d92463e4b87b), Stack size too large. Stack address: 0x7fb7fddf0000, frame address: 0x7fb7fe1ef100, stack size: 4198144, maximum stack size: 8388608 2025.07.28 11:53:00.415936 [ 17207 ] {c88d86d9-1bf7-43f8-8834-04c687184b57} PushingToViews: Failed to push block to view test_5.v1 (4ae2feef-b6fa-47ac-b20c-744da14b2a0a), Stack size too large. Stack address: 0x7fb7fddf0000, frame address: 0x7fb7fe1ef100, stack size: 4198144, maximum stack size: 8388608 2025.07.28 11:53:00.418011 [ 17207 ] {c88d86d9-1bf7-43f8-8834-04c687184b57} PushingToViews: Failed to push block to view test_5.v2 (7c22a887-3ed3-40f1-a092-d92463e4b87b), Stack size too large. Stack address: 0x7fb7fddf0000, frame address: 0x7fb7fe1ef100, stack size: 4198144, maximum stack size: 8388608 2025.07.28 11:53:00.419909 [ 17207 ] {c88d86d9-1bf7-43f8-8834-04c687184b57} PushingToViews: Failed to push block to view test_5.v1 (4ae2feef-b6fa-47ac-b20c-744da14b2a0a), Stack size too large. Stack address: 0x7fb7fddf0000, frame address: 0x7fb7fe1ef100, stack size: 4198144, maximum stack size: 8388608 2025.07.28 11:53:00.422425 [ 17207 ] {c88d86d9-1bf7-43f8-8834-04c687184b57} PushingToViews: Failed to push block to view test_5.v2 (7c22a887-3ed3-40f1-a092-d92463e4b87b), Stack size too large. Stack address: 0x7fb7fddf0000, frame address: 0x7fb7fe1ef100, stack size: 4198144, maximum stack size: 8388608 2025.07.28 11:53:00.427789 [ 17207 ] {c88d86d9-1bf7-43f8-8834-04c687184b57} PushingToViews: Failed to push block to view test_5.v1 (4ae2feef-b6fa-47ac-b20c-744da14b2a0a), Stack size too large. Stack address: 0x7fb7fddf0000, frame address: 0x7fb7fe1ef100, stack size: 4198144, maximum stack size: 8388608 2025.07.28 11:53:00.438816 [ 17207 ] {c88d86d9-1bf7-43f8-8834-04c687184b57} PushingToViews: Failed to push block to view test_5.v2 (7c22a887-3ed3-40f1-a092-d92463e4b87b), Stack size too large. Stack address: 0x7fb7fddf0000, frame address: 0x7fb7fe1ef100, stack size: 4198144, maximum stack size: 8388608 2025.07.28 11:53:00.440942 [ 17207 ] {c88d86d9-1bf7-43f8-8834-04c687184b57} PushingToViews: Failed to push block to view test_5.v1 (4ae2feef-b6fa-47ac-b20c-744da14b2a0a), Stack size too large. Stack address: 0x7fb7fddf0000, frame address: 0x7fb7fe1ef100, stack size: 4198144, maximum stack size: 8388608 2025.07.28 11:53:00.448722 [ 17207 ] {c88d86d9-1bf7-43f8-8834-04c687184b57} PushingToViews: Failed to push block to view test_5.v2 (7c22a887-3ed3-40f1-a092-d92463e4b87b), Stack size too large. Stack address: 0x7fb7fddf0000, frame address: 0x7fb7fe1ef100, stack size: 4198144, maximum stack size: 8388608 2025.07.28 11:53:00.449625 [ 17207 ] {c88d86d9-1bf7-43f8-8834-04c687184b57} PushingToViews: Failed to push block to view test_5.v1 (4ae2feef-b6fa-47ac-b20c-744da14b2a0a), Stack size too large. Stack address: 0x7fb7fddf0000, frame address: 0x7fb7fe1ef100, stack size: 4198144, maximum stack size: 8388608 2025.07.28 11:53:00.451029 [ 17207 ] {c88d86d9-1bf7-43f8-8834-04c687184b57} PushingToViews: Failed to push block to view test_5.v2 (7c22a887-3ed3-40f1-a092-d92463e4b87b), Stack size too large. Stack address: 0x7fb7fddf0000, frame address: 0x7fb7fe1ef100, stack size: 4198144, maximum stack size: 8388608 2025.07.28 11:53:00.452887 [ 17207 ] {c88d86d9-1bf7-43f8-8834-04c687184b57} PushingToViews: Failed to push block to view test_5.v1 (4ae2feef-b6fa-47ac-b20c-744da14b2a0a), Stack size too large. Stack address: 0x7fb7fddf0000, frame address: 0x7fb7fe1ef100, stack size: 4198144, maximum stack size: 8388608 2025.07.28 11:53:00.456828 [ 17207 ] {c88d86d9-1bf7-43f8-8834-04c687184b57} PushingToViews: Failed to push block to view test_5.v2 (7c22a887-3ed3-40f1-a092-d92463e4b87b), Stack size too large. Stack address: 0x7fb7fddf0000, frame address: 0x7fb7fe1ef100, stack size: 4198144, maximum stack size: 8388608 2025.07.28 11:53:00.458560 [ 17207 ] {c88d86d9-1bf7-43f8-8834-04c687184b57} PushingToViews: Failed to push block to view test_5.v1 (4ae2feef-b6fa-47ac-b20c-744da14b2a0a), Stack size too large. Stack address: 0x7fb7fddf0000, frame address: 0x7fb7fe1ef100, stack size: 4198144, maximum stack size: 8388608 2025.07.28 11:53:00.459636 [ 17207 ] {c88d86d9-1bf7-43f8-8834-04c687184b57} PushingToViews: Failed to push block to view test_5.v2 (7c22a887-3ed3-40f1-a092-d92463e4b87b), Stack size too large. Stack address: 0x7fb7fddf0000, frame address: 0x7fb7fe1ef100, stack size: 4198144, maximum stack size: 8388608 2025.07.28 11:53:00.461136 [ 17207 ] {c88d86d9-1bf7-43f8-8834-04c687184b57} PushingToViews: Failed to push block to view test_5.v1 (4ae2feef-b6fa-47ac-b20c-744da14b2a0a), Stack size too large. Stack address: 0x7fb7fddf0000, frame address: 0x7fb7fe1ef100, stack size: 4198144, maximum stack size: 8388608 2025.07.28 11:53:00.461831 [ 17207 ] {c88d86d9-1bf7-43f8-8834-04c687184b57} PushingToViews: Failed to push block to view test_5.v2 (7c22a887-3ed3-40f1-a092-d92463e4b87b), Stack size too large. Stack address: 0x7fb7fddf0000, frame address: 0x7fb7fe1ef100, stack size: 4198144, maximum stack size: 8388608 2025.07.28 11:53:00.468307 [ 17207 ] {c88d86d9-1bf7-43f8-8834-04c687184b57} PushingToViews: Failed to push block to view test_5.v1 (4ae2feef-b6fa-47ac-b20c-744da14b2a0a), Stack size too large. Stack address: 0x7fb7fddf0000, frame address: 0x7fb7fe1ef100, stack size: 4198144, maximum stack size: 8388608 2025.07.28 11:53:00.481896 [ 17207 ] {c88d86d9-1bf7-43f8-8834-04c687184b57} PushingToViews: Failed to push block to view test_5.v2 (7c22a887-3ed3-40f1-a092-d92463e4b87b), Stack size too large. Stack address: 0x7fb7fddf0000, frame address: 0x7fb7fe1ef100, stack size: 4198144, maximum stack size: 8388608 2025.07.28 11:53:00.488801 [ 17207 ] {c88d86d9-1bf7-43f8-8834-04c687184b57} PushingToViews: Failed to push block to view test_5.v1 (4ae2feef-b6fa-47ac-b20c-744da14b2a0a), Stack size too large. Stack address: 0x7fb7fddf0000, frame address: 0x7fb7fe1ef100, stack size: 4198144, maximum stack size: 8388608 2025.07.28 11:53:00.498965 [ 17207 ] {c88d86d9-1bf7-43f8-8834-04c687184b57} PushingToViews: Failed to push block to view test_5.v2 (7c22a887-3ed3-40f1-a092-d92463e4b87b), Stack size too large. Stack address: 0x7fb7fddf0000, frame address: 0x7fb7fe1ef100, stack size: 4198144, maximum stack size: 8388608 2025.07.28 11:53:00.504050 [ 17207 ] {c88d86d9-1bf7-43f8-8834-04c687184b57} PushingToViews: Failed to push block to view test_5.v1 (4ae2feef-b6fa-47ac-b20c-744da14b2a0a), Stack size too large. Stack address: 0x7fb7fddf0000, frame address: 0x7fb7fe1ef100, stack size: 4198144, maximum stack size: 8388608 2025.07.28 11:53:00.524668 [ 17207 ] {c88d86d9-1bf7-43f8-8834-04c687184b57} PushingToViews: Failed to push block to view test_5.v2 (7c22a887-3ed3-40f1-a092-d92463e4b87b), Stack size too large. Stack address: 0x7fb7fddf0000, frame address: 0x7fb7fe1ef100, stack size: 4198144, maximum stack size: 8388608 2025.07.28 11:53:00.531235 [ 17207 ] {c88d86d9-1bf7-43f8-8834-04c687184b57} PushingToViews: Failed to push block to view test_5.v1 (4ae2feef-b6fa-47ac-b20c-744da14b2a0a), Stack size too large. Stack address: 0x7fb7fddf0000, frame address: 0x7fb7fe1ef100, stack size: 4198144, maximum stack size: 8388608 2025.07.28 11:53:00.553383 [ 17207 ] {c88d86d9-1bf7-43f8-8834-04c687184b57} PushingToViews: Failed to push block to view test_5.v2 (7c22a887-3ed3-40f1-a092-d92463e4b87b), Stack size too large. Stack address: 0x7fb7fddf0000, frame address: 0x7fb7fe1ef100, stack size: 4198144, maximum stack size: 8388608 2025.07.28 11:53:00.559724 [ 17207 ] {c88d86d9-1bf7-43f8-8834-04c687184b57} PushingToViews: Failed to push block to view test_5.v1 (4ae2feef-b6fa-47ac-b20c-744da14b2a0a), Stack size too large. Stack address: 0x7fb7fddf0000, frame address: 0x7fb7fe1ef100, stack size: 4198144, maximum stack size: 8388608 2025.07.28 11:53:00.563643 [ 17207 ] {c88d86d9-1bf7-43f8-8834-04c687184b57} PushingToViews: Failed to push block to view test_5.v2 (7c22a887-3ed3-40f1-a092-d92463e4b87b), Stack size too large. Stack address: 0x7fb7fddf0000, frame address: 0x7fb7fe1ef100, stack size: 4198144, maximum stack size: 8388608 2025.07.28 11:53:00.564667 [ 17207 ] {c88d86d9-1bf7-43f8-8834-04c687184b57} PushingToViews: Failed to push block to view test_5.v1 (4ae2feef-b6fa-47ac-b20c-744da14b2a0a), Stack size too large. Stack address: 0x7fb7fddf0000, frame address: 0x7fb7fe1ef100, stack size: 4198144, maximum stack size: 8388608 2025.07.28 11:53:00.570065 [ 17207 ] {c88d86d9-1bf7-43f8-8834-04c687184b57} PushingToViews: Failed to push block to view test_5.v2 (7c22a887-3ed3-40f1-a092-d92463e4b87b), Stack size too large. Stack address: 0x7fb7fddf0000, frame address: 0x7fb7fe1ef100, stack size: 4198144, maximum stack size: 8388608 2025.07.28 11:53:00.573314 [ 17207 ] {c88d86d9-1bf7-43f8-8834-04c687184b57} PushingToViews: Failed to push block to view test_5.v1 (4ae2feef-b6fa-47ac-b20c-744da14b2a0a), Stack size too large. Stack address: 0x7fb7fddf0000, frame address: 0x7fb7fe1ef100, stack size: 4198144, maximum stack size: 8388608 2025.07.28 11:53:00.580022 [ 17207 ] {c88d86d9-1bf7-43f8-8834-04c687184b57} PushingToViews: Failed to push block to view test_5.v2 (7c22a887-3ed3-40f1-a092-d92463e4b87b), Stack size too large. Stack address: 0x7fb7fddf0000, frame address: 0x7fb7fe1ef100, stack size: 4198144, maximum stack size: 8388608 2025.07.28 11:53:00.587658 [ 17207 ] {c88d86d9-1bf7-43f8-8834-04c687184b57} PushingToViews: Failed to push block to view test_5.v1 (4ae2feef-b6fa-47ac-b20c-744da14b2a0a), Stack size too large. Stack address: 0x7fb7fddf0000, frame address: 0x7fb7fe1ef100, stack size: 4198144, maximum stack size: 8388608 2025.07.28 11:53:00.669446 [ 17207 ] {c88d86d9-1bf7-43f8-8834-04c687184b57} PushingToViews: Failed to push block to view test_5.v2 (7c22a887-3ed3-40f1-a092-d92463e4b87b), Stack size too large. Stack address: 0x7fb7fddf0000, frame address: 0x7fb7fe1ef100, stack size: 4198144, maximum stack size: 8388608 2025.07.28 11:53:00.672438 [ 17207 ] {c88d86d9-1bf7-43f8-8834-04c687184b57} PushingToViews: Failed to push block to view test_5.v1 (4ae2feef-b6fa-47ac-b20c-744da14b2a0a), Stack size too large. Stack address: 0x7fb7fddf0000, frame address: 0x7fb7fe1ef100, stack size: 4198144, maximum stack size: 8388608 2025.07.28 11:53:00.673847 [ 17207 ] {c88d86d9-1bf7-43f8-8834-04c687184b57} PushingToViews: Failed to push block to view test_5.v2 (7c22a887-3ed3-40f1-a092-d92463e4b87b), Stack size too large. Stack address: 0x7fb7fddf0000, frame address: 0x7fb7fe1ef100, stack size: 4198144, maximum stack size: 8388608 2025.07.28 11:53:00.677556 [ 17207 ] {c88d86d9-1bf7-43f8-8834-04c687184b57} PushingToViews: Failed to push block to view test_5.v1 (4ae2feef-b6fa-47ac-b20c-744da14b2a0a), Stack size too large. Stack address: 0x7fb7fddf0000, frame address: 0x7fb7fe1ef100, stack size: 4198144, maximum stack size: 8388608 2025.07.28 11:53:00.679684 [ 17207 ] {c88d86d9-1bf7-43f8-8834-04c687184b57} PushingToViews: Failed to push block to view test_5.v2 (7c22a887-3ed3-40f1-a092-d92463e4b87b), Stack size too large. Stack address: 0x7fb7fddf0000, frame address: 0x7fb7fe1ef100, stack size: 4198144, maximum stack size: 8388608 2025.07.28 11:53:00.680615 [ 17207 ] {c88d86d9-1bf7-43f8-8834-04c687184b57} PushingToViews: Failed to push block to view test_5.v1 (4ae2feef-b6fa-47ac-b20c-744da14b2a0a), Stack size too large. Stack address: 0x7fb7fddf0000, frame address: 0x7fb7fe1ef100, stack size: 4198144, maximum stack size: 8388608 2025.07.28 11:53:00.682092 [ 17207 ] {c88d86d9-1bf7-43f8-8834-04c687184b57} PushingToViews: Failed to push block to view test_5.v2 (7c22a887-3ed3-40f1-a092-d92463e4b87b), Stack size too large. Stack address: 0x7fb7fddf0000, frame address: 0x7fb7fe1ef100, stack size: 4198144, maximum stack size: 8388608 2025.07.28 11:53:00.683760 [ 17207 ] {c88d86d9-1bf7-43f8-8834-04c687184b57} PushingToViews: Failed to push block to view test_5.v1 (4ae2feef-b6fa-47ac-b20c-744da14b2a0a), Stack size too large. Stack address: 0x7fb7fddf0000, frame address: 0x7fb7fe1ef100, stack size: 4198144, maximum stack size: 8388608 2025.07.28 11:53:00.685356 [ 3971 ] {} test_13.rmt2 (7f9b740d-015c-470e-8cc6-8ba33be0dc63): auto DB::StorageReplicatedMergeTree::processQueueEntry(ReplicatedMergeTreeQueue::SelectedEntryPtr)::(anonymous class)::operator()(LogEntryPtr &) const: Code: 86. DB::HTTPException: Received error from remote server http://146b4357c08d:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Ftest%2F01165%2Ftest_13%2Frmt%2Freplicas%2F1&part=20250728_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.6.10636.altinitytest (altinity build)) '. (RECEIVED_ERROR_FROM_REMOTE_IO_SERVER), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.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 const&, int&&, String const&, unsigned long&&, String const&) @ 0x000000000feda8d9 4. /build/src/IO/HTTPCommon.cpp:104: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x000000000feda6e2 5. /build/src/IO/HTTPCommon.cpp:93: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x000000000feda537 6. /build/src/IO/ReadWriteBufferFromHTTP.cpp:277: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x000000001184a4c4 7. /build/src/IO/ReadWriteBufferFromHTTP.cpp:285: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x000000001184a615 8. /build/src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x000000001184ae59 9. /build/src/IO/ReadWriteBufferFromHTTP.cpp:472: void std::__function::__policy_invoker::__call_impl[abi:se190107]>(std::__function::__policy_storage const*) @ 0x000000001184cedd 10. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001184858b 11. /build/src/IO/ReadWriteBufferFromHTTP.cpp:465: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x000000001184bf0b 12. /build/src/IO/ReadBuffer.h:60: DB::ReadBuffer::next() @ 0x000000000a148c7b 13. /build/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) @ 0x0000000011849fb2 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]>&)>&, 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&) @ 0x0000000011841980 15. /build/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) @ 0x000000001621208e 16. /build/src/Storages/StorageReplicatedMergeTree.cpp:5228: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl[abi:se190107] const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000015f9a5fe 17. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000015ed8bfd 18. /build/src/Storages/StorageReplicatedMergeTree.cpp:2514: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x0000000015ec9aab 19. /build/src/Storages/StorageReplicatedMergeTree.cpp:2349: DB::StorageReplicatedMergeTree::executeLogEntry(DB::ReplicatedMergeTreeLogEntry&) @ 0x0000000015eba91b 20. /build/src/Storages/StorageReplicatedMergeTree.cpp:3876: bool std::__function::__policy_invoker&)>::__call_impl[abi:se190107])::$_1, bool (std::shared_ptr&)>>(std::__function::__policy_storage const*, std::shared_ptr&) @ 0x0000000015f9837e 21. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000165d6fc3 22. /build/src/Storages/StorageReplicatedMergeTree.cpp:3872: DB::StorageReplicatedMergeTree::processQueueEntry(std::shared_ptr) @ 0x0000000015efc18a 23. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001624c1b2 24. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000162f9c70 25. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x00000000162fa55a 26. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc6653 27. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000000fccc4c3 28. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc3d92 29. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fcca080 30. ? @ 0x00007fbc6213eac3 31. ? @ 0x00007fbc621d0850 (version 25.3.6.10636.altinitytest (altinity build)) 2025.07.28 11:53:00.687807 [ 17207 ] {c88d86d9-1bf7-43f8-8834-04c687184b57} PushingToViews: Failed to push block to view test_5.v2 (7c22a887-3ed3-40f1-a092-d92463e4b87b), Stack size too large. Stack address: 0x7fb7fddf0000, frame address: 0x7fb7fe1ef100, stack size: 4198144, maximum stack size: 8388608 2025.07.28 11:53:00.769495 [ 17207 ] {c88d86d9-1bf7-43f8-8834-04c687184b57} PushingToViews: Failed to push block to view test_5.v1 (4ae2feef-b6fa-47ac-b20c-744da14b2a0a), Stack size too large. Stack address: 0x7fb7fddf0000, frame address: 0x7fb7fe1ef100, stack size: 4198144, maximum stack size: 8388608 2025.07.28 11:53:00.771104 [ 17207 ] {c88d86d9-1bf7-43f8-8834-04c687184b57} PushingToViews: Failed to push block to view test_5.v2 (7c22a887-3ed3-40f1-a092-d92463e4b87b), Stack size too large. Stack address: 0x7fb7fddf0000, frame address: 0x7fb7fe1ef100, stack size: 4198144, maximum stack size: 8388608 2025.07.28 11:53:00.785255 [ 17207 ] {c88d86d9-1bf7-43f8-8834-04c687184b57} PushingToViews: Failed to push block to view test_5.v1 (4ae2feef-b6fa-47ac-b20c-744da14b2a0a), Stack size too large. Stack address: 0x7fb7fddf0000, frame address: 0x7fb7fe1ef100, stack size: 4198144, maximum stack size: 8388608 2025.07.28 11:53:00.786532 [ 17207 ] {c88d86d9-1bf7-43f8-8834-04c687184b57} PushingToViews: Failed to push block to view test_5.v2 (7c22a887-3ed3-40f1-a092-d92463e4b87b), Stack size too large. Stack address: 0x7fb7fddf0000, frame address: 0x7fb7fe1ef100, stack size: 4198144, maximum stack size: 8388608 2025.07.28 11:53:00.787554 [ 17207 ] {c88d86d9-1bf7-43f8-8834-04c687184b57} PushingToViews: Failed to push block to view test_5.v1 (4ae2feef-b6fa-47ac-b20c-744da14b2a0a), Stack size too large. Stack address: 0x7fb7fddf0000, frame address: 0x7fb7fe1ef100, stack size: 4198144, maximum stack size: 8388608 2025.07.28 11:53:00.790900 [ 17207 ] {c88d86d9-1bf7-43f8-8834-04c687184b57} PushingToViews: Failed to push block to view test_5.v2 (7c22a887-3ed3-40f1-a092-d92463e4b87b), Stack size too large. Stack address: 0x7fb7fddf0000, frame address: 0x7fb7fe1ef100, stack size: 4198144, maximum stack size: 8388608 2025.07.28 11:53:00.792727 [ 17207 ] {c88d86d9-1bf7-43f8-8834-04c687184b57} PushingToViews: Failed to push block to view test_5.v1 (4ae2feef-b6fa-47ac-b20c-744da14b2a0a), Stack size too large. Stack address: 0x7fb7fddf0000, frame address: 0x7fb7fe1ef100, stack size: 4198144, maximum stack size: 8388608 2025.07.28 11:53:00.794182 [ 17207 ] {c88d86d9-1bf7-43f8-8834-04c687184b57} PushingToViews: Failed to push block to view test_5.v2 (7c22a887-3ed3-40f1-a092-d92463e4b87b), Stack size too large. Stack address: 0x7fb7fddf0000, frame address: 0x7fb7fe1ef100, stack size: 4198144, maximum stack size: 8388608 2025.07.28 11:53:00.795555 [ 17207 ] {c88d86d9-1bf7-43f8-8834-04c687184b57} PushingToViews: Failed to push block to view test_5.v1 (4ae2feef-b6fa-47ac-b20c-744da14b2a0a), Stack size too large. Stack address: 0x7fb7fddf0000, frame address: 0x7fb7fe1ef100, stack size: 4198144, maximum stack size: 8388608 2025.07.28 11:53:00.797241 [ 17207 ] {c88d86d9-1bf7-43f8-8834-04c687184b57} PushingToViews: Failed to push block to view test_5.v2 (7c22a887-3ed3-40f1-a092-d92463e4b87b), Stack size too large. Stack address: 0x7fb7fddf0000, frame address: 0x7fb7fe1ef100, stack size: 4198144, maximum stack size: 8388608 2025.07.28 11:53:00.797973 [ 17207 ] {c88d86d9-1bf7-43f8-8834-04c687184b57} PushingToViews: Failed to push block to view test_5.v1 (4ae2feef-b6fa-47ac-b20c-744da14b2a0a), Stack size too large. Stack address: 0x7fb7fddf0000, frame address: 0x7fb7fe1ef100, stack size: 4198144, maximum stack size: 8388608 2025.07.28 11:53:00.799102 [ 17207 ] {c88d86d9-1bf7-43f8-8834-04c687184b57} PushingToViews: Failed to push block to view test_5.v2 (7c22a887-3ed3-40f1-a092-d92463e4b87b), Stack size too large. Stack address: 0x7fb7fddf0000, frame address: 0x7fb7fe1ef100, stack size: 4198144, maximum stack size: 8388608 2025.07.28 11:53:00.800504 [ 17207 ] {c88d86d9-1bf7-43f8-8834-04c687184b57} PushingToViews: Failed to push block to view test_5.v1 (4ae2feef-b6fa-47ac-b20c-744da14b2a0a), Stack size too large. Stack address: 0x7fb7fddf0000, frame address: 0x7fb7fe1ef100, stack size: 4198144, maximum stack size: 8388608 2025.07.28 11:53:00.801414 [ 17207 ] {c88d86d9-1bf7-43f8-8834-04c687184b57} PushingToViews: Failed to push block to view test_5.v2 (7c22a887-3ed3-40f1-a092-d92463e4b87b), Stack size too large. Stack address: 0x7fb7fddf0000, frame address: 0x7fb7fe1ef100, stack size: 4198144, maximum stack size: 8388608 2025.07.28 11:53:00.802518 [ 17207 ] {c88d86d9-1bf7-43f8-8834-04c687184b57} PushingToViews: Failed to push block to view test_5.v1 (4ae2feef-b6fa-47ac-b20c-744da14b2a0a), Stack size too large. Stack address: 0x7fb7fddf0000, frame address: 0x7fb7fe1ef100, stack size: 4198144, maximum stack size: 8388608 2025.07.28 11:53:00.807496 [ 17207 ] {c88d86d9-1bf7-43f8-8834-04c687184b57} PushingToViews: Failed to push block to view test_5.v2 (7c22a887-3ed3-40f1-a092-d92463e4b87b), Stack size too large. Stack address: 0x7fb7fddf0000, frame address: 0x7fb7fe1ef100, stack size: 4198144, maximum stack size: 8388608 2025.07.28 11:53:00.808569 [ 17207 ] {c88d86d9-1bf7-43f8-8834-04c687184b57} PushingToViews: Failed to push block to view test_5.v1 (4ae2feef-b6fa-47ac-b20c-744da14b2a0a), Stack size too large. Stack address: 0x7fb7fddf0000, frame address: 0x7fb7fe1ef100, stack size: 4198144, maximum stack size: 8388608 2025.07.28 11:53:00.809682 [ 17207 ] {c88d86d9-1bf7-43f8-8834-04c687184b57} PushingToViews: Failed to push block to view test_5.v2 (7c22a887-3ed3-40f1-a092-d92463e4b87b), Stack size too large. Stack address: 0x7fb7fddf0000, frame address: 0x7fb7fe1ef100, stack size: 4198144, maximum stack size: 8388608 2025.07.28 11:53:00.811791 [ 17207 ] {c88d86d9-1bf7-43f8-8834-04c687184b57} PushingToViews: Failed to push block to view test_5.v1 (4ae2feef-b6fa-47ac-b20c-744da14b2a0a), Stack size too large. Stack address: 0x7fb7fddf0000, frame address: 0x7fb7fe1ef100, stack size: 4198144, maximum stack size: 8388608 2025.07.28 11:53:00.814484 [ 17207 ] {c88d86d9-1bf7-43f8-8834-04c687184b57} PushingToViews: Failed to push block to view test_5.v2 (7c22a887-3ed3-40f1-a092-d92463e4b87b), Stack size too large. Stack address: 0x7fb7fddf0000, frame address: 0x7fb7fe1ef100, stack size: 4198144, maximum stack size: 8388608 2025.07.28 11:53:00.815653 [ 17207 ] {c88d86d9-1bf7-43f8-8834-04c687184b57} PushingToViews: Failed to push block to view test_5.v1 (4ae2feef-b6fa-47ac-b20c-744da14b2a0a), Stack size too large. Stack address: 0x7fb7fddf0000, frame address: 0x7fb7fe1ef100, stack size: 4198144, maximum stack size: 8388608 2025.07.28 11:53:00.817129 [ 17207 ] {c88d86d9-1bf7-43f8-8834-04c687184b57} PushingToViews: Failed to push block to view test_5.v2 (7c22a887-3ed3-40f1-a092-d92463e4b87b), Stack size too large. Stack address: 0x7fb7fddf0000, frame address: 0x7fb7fe1ef100, stack size: 4198144, maximum stack size: 8388608 2025.07.28 11:53:00.819010 [ 17207 ] {c88d86d9-1bf7-43f8-8834-04c687184b57} PushingToViews: Failed to push block to view test_5.v1 (4ae2feef-b6fa-47ac-b20c-744da14b2a0a), Stack size too large. Stack address: 0x7fb7fddf0000, frame address: 0x7fb7fe1ef100, stack size: 4198144, maximum stack size: 8388608 2025.07.28 11:53:00.828996 [ 17207 ] {c88d86d9-1bf7-43f8-8834-04c687184b57} PushingToViews: Failed to push block to view test_5.v2 (7c22a887-3ed3-40f1-a092-d92463e4b87b), Stack size too large. Stack address: 0x7fb7fddf0000, frame address: 0x7fb7fe1ef100, stack size: 4198144, maximum stack size: 8388608 2025.07.28 11:53:00.840548 [ 17207 ] {c88d86d9-1bf7-43f8-8834-04c687184b57} PushingToViews: Failed to push block to view test_5.v1 (4ae2feef-b6fa-47ac-b20c-744da14b2a0a), Stack size too large. Stack address: 0x7fb7fddf0000, frame address: 0x7fb7fe1ef100, stack size: 4198144, maximum stack size: 8388608 2025.07.28 11:53:00.848816 [ 17207 ] {c88d86d9-1bf7-43f8-8834-04c687184b57} PushingToViews: Failed to push block to view test_5.v2 (7c22a887-3ed3-40f1-a092-d92463e4b87b), Stack size too large. Stack address: 0x7fb7fddf0000, frame address: 0x7fb7fe1ef100, stack size: 4198144, maximum stack size: 8388608 2025.07.28 11:53:00.853786 [ 17207 ] {c88d86d9-1bf7-43f8-8834-04c687184b57} PushingToViews: Failed to push block to view test_5.v1 (4ae2feef-b6fa-47ac-b20c-744da14b2a0a), Stack size too large. Stack address: 0x7fb7fddf0000, frame address: 0x7fb7fe1ef100, stack size: 4198144, maximum stack size: 8388608 2025.07.28 11:53:00.859782 [ 17207 ] {c88d86d9-1bf7-43f8-8834-04c687184b57} PushingToViews: Failed to push block to view test_5.v2 (7c22a887-3ed3-40f1-a092-d92463e4b87b), Stack size too large. Stack address: 0x7fb7fddf0000, frame address: 0x7fb7fe1ef100, stack size: 4198144, maximum stack size: 8388608 2025.07.28 11:53:00.868065 [ 17207 ] {c88d86d9-1bf7-43f8-8834-04c687184b57} PushingToViews: Failed to push block to view test_5.v1 (4ae2feef-b6fa-47ac-b20c-744da14b2a0a), Stack size too large. Stack address: 0x7fb7fddf0000, frame address: 0x7fb7fe1ef100, stack size: 4198144, maximum stack size: 8388608 2025.07.28 11:53:00.882679 [ 17207 ] {c88d86d9-1bf7-43f8-8834-04c687184b57} PushingToViews: Failed to push block to view test_5.v2 (7c22a887-3ed3-40f1-a092-d92463e4b87b), Stack size too large. Stack address: 0x7fb7fddf0000, frame address: 0x7fb7fe1ef100, stack size: 4198144, maximum stack size: 8388608 2025.07.28 11:53:00.884851 [ 17207 ] {c88d86d9-1bf7-43f8-8834-04c687184b57} PushingToViews: Failed to push block to view test_5.v1 (4ae2feef-b6fa-47ac-b20c-744da14b2a0a), Stack size too large. Stack address: 0x7fb7fddf0000, frame address: 0x7fb7fe1ef100, stack size: 4198144, maximum stack size: 8388608 2025.07.28 11:53:00.885923 [ 17207 ] {c88d86d9-1bf7-43f8-8834-04c687184b57} PushingToViews: Failed to push block to view test_5.v2 (7c22a887-3ed3-40f1-a092-d92463e4b87b), Stack size too large. Stack address: 0x7fb7fddf0000, frame address: 0x7fb7fe1ef100, stack size: 4198144, maximum stack size: 8388608 2025.07.28 11:53:00.888009 [ 17207 ] {c88d86d9-1bf7-43f8-8834-04c687184b57} PushingToViews: Failed to push block to view test_5.v1 (4ae2feef-b6fa-47ac-b20c-744da14b2a0a), Stack size too large. Stack address: 0x7fb7fddf0000, frame address: 0x7fb7fe1ef100, stack size: 4198144, maximum stack size: 8388608 2025.07.28 11:53:00.897397 [ 17207 ] {c88d86d9-1bf7-43f8-8834-04c687184b57} PushingToViews: Failed to push block to view test_5.v2 (7c22a887-3ed3-40f1-a092-d92463e4b87b), Stack size too large. Stack address: 0x7fb7fddf0000, frame address: 0x7fb7fe1ef100, stack size: 4198144, maximum stack size: 8388608 2025.07.28 11:53:00.900450 [ 17207 ] {c88d86d9-1bf7-43f8-8834-04c687184b57} PushingToViews: Failed to push block to view test_5.v1 (4ae2feef-b6fa-47ac-b20c-744da14b2a0a), Stack size too large. Stack address: 0x7fb7fddf0000, frame address: 0x7fb7fe1ef100, stack size: 4198144, maximum stack size: 8388608 2025.07.28 11:53:01.020412 [ 17207 ] {c88d86d9-1bf7-43f8-8834-04c687184b57} PushingToViews: Failed to push block to view test_5.v2 (7c22a887-3ed3-40f1-a092-d92463e4b87b), Stack size too large. Stack address: 0x7fb7fddf0000, frame address: 0x7fb7fe1ef100, stack size: 4198144, maximum stack size: 8388608 2025.07.28 11:53:01.021473 [ 17207 ] {c88d86d9-1bf7-43f8-8834-04c687184b57} PushingToViews: Failed to push block to view test_5.v1 (4ae2feef-b6fa-47ac-b20c-744da14b2a0a), Stack size too large. Stack address: 0x7fb7fddf0000, frame address: 0x7fb7fe1ef100, stack size: 4198144, maximum stack size: 8388608 2025.07.28 11:53:01.022505 [ 17207 ] {c88d86d9-1bf7-43f8-8834-04c687184b57} PushingToViews: Failed to push block to view test_5.v2 (7c22a887-3ed3-40f1-a092-d92463e4b87b), Stack size too large. Stack address: 0x7fb7fddf0000, frame address: 0x7fb7fe1ef100, stack size: 4198144, maximum stack size: 8388608 2025.07.28 11:53:01.030969 [ 17207 ] {c88d86d9-1bf7-43f8-8834-04c687184b57} PushingToViews: Failed to push block to view test_5.v1 (4ae2feef-b6fa-47ac-b20c-744da14b2a0a), Stack size too large. Stack address: 0x7fb7fddf0000, frame address: 0x7fb7fe1ef100, stack size: 4198144, maximum stack size: 8388608 2025.07.28 11:53:01.037960 [ 17207 ] {c88d86d9-1bf7-43f8-8834-04c687184b57} PushingToViews: Failed to push block to view test_5.v2 (7c22a887-3ed3-40f1-a092-d92463e4b87b), Stack size too large. Stack address: 0x7fb7fddf0000, frame address: 0x7fb7fe1ef100, stack size: 4198144, maximum stack size: 8388608 2025.07.28 11:53:01.046484 [ 17207 ] {c88d86d9-1bf7-43f8-8834-04c687184b57} PushingToViews: Failed to push block to view test_5.v1 (4ae2feef-b6fa-47ac-b20c-744da14b2a0a), Stack size too large. Stack address: 0x7fb7fddf0000, frame address: 0x7fb7fe1ef100, stack size: 4198144, maximum stack size: 8388608 2025.07.28 11:53:01.047720 [ 17207 ] {c88d86d9-1bf7-43f8-8834-04c687184b57} PushingToViews: Failed to push block to view test_5.v2 (7c22a887-3ed3-40f1-a092-d92463e4b87b), Stack size too large. Stack address: 0x7fb7fddf0000, frame address: 0x7fb7fe1ef100, stack size: 4198144, maximum stack size: 8388608 2025.07.28 11:53:01.048848 [ 17207 ] {c88d86d9-1bf7-43f8-8834-04c687184b57} PushingToViews: Failed to push block to view test_5.v1 (4ae2feef-b6fa-47ac-b20c-744da14b2a0a), Stack size too large. Stack address: 0x7fb7fddf0000, frame address: 0x7fb7fe1ef100, stack size: 4198144, maximum stack size: 8388608 2025.07.28 11:53:01.050355 [ 17207 ] {c88d86d9-1bf7-43f8-8834-04c687184b57} PushingToViews: Failed to push block to view test_5.v2 (7c22a887-3ed3-40f1-a092-d92463e4b87b), Stack size too large. Stack address: 0x7fb7fddf0000, frame address: 0x7fb7fe1ef100, stack size: 4198144, maximum stack size: 8388608 2025.07.28 11:53:01.064688 [ 17207 ] {c88d86d9-1bf7-43f8-8834-04c687184b57} PushingToViews: Failed to push block to view test_5.v1 (4ae2feef-b6fa-47ac-b20c-744da14b2a0a), Stack size too large. Stack address: 0x7fb7fddf0000, frame address: 0x7fb7fe1ef100, stack size: 4198144, maximum stack size: 8388608 2025.07.28 11:53:01.066363 [ 17207 ] {c88d86d9-1bf7-43f8-8834-04c687184b57} PushingToViews: Failed to push block to view test_5.v2 (7c22a887-3ed3-40f1-a092-d92463e4b87b), Stack size too large. Stack address: 0x7fb7fddf0000, frame address: 0x7fb7fe1ef100, stack size: 4198144, maximum stack size: 8388608 2025.07.28 11:53:01.067537 [ 17207 ] {c88d86d9-1bf7-43f8-8834-04c687184b57} PushingToViews: Failed to push block to view test_5.v1 (4ae2feef-b6fa-47ac-b20c-744da14b2a0a), Stack size too large. Stack address: 0x7fb7fddf0000, frame address: 0x7fb7fe1ef100, stack size: 4198144, maximum stack size: 8388608 2025.07.28 11:53:01.068360 [ 17207 ] {c88d86d9-1bf7-43f8-8834-04c687184b57} PushingToViews: Failed to push block to view test_5.v2 (7c22a887-3ed3-40f1-a092-d92463e4b87b), Stack size too large. Stack address: 0x7fb7fddf0000, frame address: 0x7fb7fe1ef100, stack size: 4198144, maximum stack size: 8388608 2025.07.28 11:53:01.072041 [ 17207 ] {c88d86d9-1bf7-43f8-8834-04c687184b57} PushingToViews: Failed to push block to view test_5.v1 (4ae2feef-b6fa-47ac-b20c-744da14b2a0a), Stack size too large. Stack address: 0x7fb7fddf0000, frame address: 0x7fb7fe1ef100, stack size: 4198144, maximum stack size: 8388608 2025.07.28 11:53:01.072849 [ 17207 ] {c88d86d9-1bf7-43f8-8834-04c687184b57} PushingToViews: Failed to push block to view test_5.v2 (7c22a887-3ed3-40f1-a092-d92463e4b87b), Stack size too large. Stack address: 0x7fb7fddf0000, frame address: 0x7fb7fe1ef100, stack size: 4198144, maximum stack size: 8388608 2025.07.28 11:53:01.073768 [ 17207 ] {c88d86d9-1bf7-43f8-8834-04c687184b57} PushingToViews: Failed to push block to view test_5.v1 (4ae2feef-b6fa-47ac-b20c-744da14b2a0a), Stack size too large. Stack address: 0x7fb7fddf0000, frame address: 0x7fb7fe1ef100, stack size: 4198144, maximum stack size: 8388608 2025.07.28 11:53:01.076493 [ 17207 ] {c88d86d9-1bf7-43f8-8834-04c687184b57} PushingToViews: Failed to push block to view test_5.v2 (7c22a887-3ed3-40f1-a092-d92463e4b87b), Stack size too large. Stack address: 0x7fb7fddf0000, frame address: 0x7fb7fe1ef100, stack size: 4198144, maximum stack size: 8388608 2025.07.28 11:53:01.077422 [ 17207 ] {c88d86d9-1bf7-43f8-8834-04c687184b57} PushingToViews: Failed to push block to view test_5.v1 (4ae2feef-b6fa-47ac-b20c-744da14b2a0a), Stack size too large. Stack address: 0x7fb7fddf0000, frame address: 0x7fb7fe1ef100, stack size: 4198144, maximum stack size: 8388608 2025.07.28 11:53:01.078846 [ 17207 ] {c88d86d9-1bf7-43f8-8834-04c687184b57} PushingToViews: Failed to push block to view test_5.v2 (7c22a887-3ed3-40f1-a092-d92463e4b87b), Stack size too large. Stack address: 0x7fb7fddf0000, frame address: 0x7fb7fe1ef100, stack size: 4198144, maximum stack size: 8388608 2025.07.28 11:53:01.079877 [ 17207 ] {c88d86d9-1bf7-43f8-8834-04c687184b57} PushingToViews: Failed to push block to view test_5.v1 (4ae2feef-b6fa-47ac-b20c-744da14b2a0a), Stack size too large. Stack address: 0x7fb7fddf0000, frame address: 0x7fb7fe1ef100, stack size: 4198144, maximum stack size: 8388608 2025.07.28 11:53:01.092108 [ 17207 ] {c88d86d9-1bf7-43f8-8834-04c687184b57} PushingToViews: Failed to push block to view test_5.v2 (7c22a887-3ed3-40f1-a092-d92463e4b87b), Stack size too large. Stack address: 0x7fb7fddf0000, frame address: 0x7fb7fe1ef100, stack size: 4198144, maximum stack size: 8388608 2025.07.28 11:53:01.093281 [ 17207 ] {c88d86d9-1bf7-43f8-8834-04c687184b57} PushingToViews: Failed to push block to view test_5.v1 (4ae2feef-b6fa-47ac-b20c-744da14b2a0a), Stack size too large. Stack address: 0x7fb7fddf0000, frame address: 0x7fb7fe1ef100, stack size: 4198144, maximum stack size: 8388608 2025.07.28 11:53:01.096541 [ 17207 ] {c88d86d9-1bf7-43f8-8834-04c687184b57} PushingToViews: Failed to push block to view test_5.v2 (7c22a887-3ed3-40f1-a092-d92463e4b87b), Stack size too large. Stack address: 0x7fb7fddf0000, frame address: 0x7fb7fe1ef100, stack size: 4198144, maximum stack size: 8388608 2025.07.28 11:53:01.097730 [ 17207 ] {c88d86d9-1bf7-43f8-8834-04c687184b57} PushingToViews: Failed to push block to view test_5.v1 (4ae2feef-b6fa-47ac-b20c-744da14b2a0a), Stack size too large. Stack address: 0x7fb7fddf0000, frame address: 0x7fb7fe1ef100, stack size: 4198144, maximum stack size: 8388608 2025.07.28 11:53:01.099414 [ 17207 ] {c88d86d9-1bf7-43f8-8834-04c687184b57} PushingToViews: Failed to push block to view test_5.v2 (7c22a887-3ed3-40f1-a092-d92463e4b87b), Stack size too large. Stack address: 0x7fb7fddf0000, frame address: 0x7fb7fe1ef100, stack size: 4198144, maximum stack size: 8388608 2025.07.28 11:53:01.111364 [ 17207 ] {c88d86d9-1bf7-43f8-8834-04c687184b57} PushingToViews: Failed to push block to view test_5.v1 (4ae2feef-b6fa-47ac-b20c-744da14b2a0a), Stack size too large. Stack address: 0x7fb7fddf0000, frame address: 0x7fb7fe1ef100, stack size: 4198144, maximum stack size: 8388608 2025.07.28 11:53:01.114330 [ 17207 ] {c88d86d9-1bf7-43f8-8834-04c687184b57} PushingToViews: Failed to push block to view test_5.v2 (7c22a887-3ed3-40f1-a092-d92463e4b87b), Stack size too large. Stack address: 0x7fb7fddf0000, frame address: 0x7fb7fe1ef100, stack size: 4198144, maximum stack size: 8388608 2025.07.28 11:53:01.115608 [ 17207 ] {c88d86d9-1bf7-43f8-8834-04c687184b57} PushingToViews: Failed to push block to view test_5.v1 (4ae2feef-b6fa-47ac-b20c-744da14b2a0a), Stack size too large. Stack address: 0x7fb7fddf0000, frame address: 0x7fb7fe1ef100, stack size: 4198144, maximum stack size: 8388608 2025.07.28 11:53:01.116539 [ 17207 ] {c88d86d9-1bf7-43f8-8834-04c687184b57} PushingToViews: Failed to push block to view test_5.v2 (7c22a887-3ed3-40f1-a092-d92463e4b87b), Stack size too large. Stack address: 0x7fb7fddf0000, frame address: 0x7fb7fe1ef100, stack size: 4198144, maximum stack size: 8388608 2025.07.28 11:53:01.119672 [ 17207 ] {c88d86d9-1bf7-43f8-8834-04c687184b57} PushingToViews: Failed to push block to view test_5.v1 (4ae2feef-b6fa-47ac-b20c-744da14b2a0a), Stack size too large. Stack address: 0x7fb7fddf0000, frame address: 0x7fb7fe1ef100, stack size: 4198144, maximum stack size: 8388608 2025.07.28 11:53:01.124222 [ 17207 ] {c88d86d9-1bf7-43f8-8834-04c687184b57} PushingToViews: Failed to push block to view test_5.v2 (7c22a887-3ed3-40f1-a092-d92463e4b87b), Stack size too large. Stack address: 0x7fb7fddf0000, frame address: 0x7fb7fe1ef100, stack size: 4198144, maximum stack size: 8388608 2025.07.28 11:53:01.130385 [ 17207 ] {c88d86d9-1bf7-43f8-8834-04c687184b57} PushingToViews: Failed to push block to view test_5.v1 (4ae2feef-b6fa-47ac-b20c-744da14b2a0a), Stack size too large. Stack address: 0x7fb7fddf0000, frame address: 0x7fb7fe1ef100, stack size: 4198144, maximum stack size: 8388608 2025.07.28 11:53:01.131283 [ 17207 ] {c88d86d9-1bf7-43f8-8834-04c687184b57} PushingToViews: Failed to push block to view test_5.v2 (7c22a887-3ed3-40f1-a092-d92463e4b87b), Stack size too large. Stack address: 0x7fb7fddf0000, frame address: 0x7fb7fe1ef100, stack size: 4198144, maximum stack size: 8388608 2025.07.28 11:53:01.141177 [ 17207 ] {c88d86d9-1bf7-43f8-8834-04c687184b57} PushingToViews: Failed to push block to view test_5.v1 (4ae2feef-b6fa-47ac-b20c-744da14b2a0a), Stack size too large. Stack address: 0x7fb7fddf0000, frame address: 0x7fb7fe1ef100, stack size: 4198144, maximum stack size: 8388608 2025.07.28 11:53:01.145509 [ 17207 ] {c88d86d9-1bf7-43f8-8834-04c687184b57} PushingToViews: Failed to push block to view test_5.v2 (7c22a887-3ed3-40f1-a092-d92463e4b87b), Stack size too large. Stack address: 0x7fb7fddf0000, frame address: 0x7fb7fe1ef100, stack size: 4198144, maximum stack size: 8388608 2025.07.28 11:53:01.146330 [ 17207 ] {c88d86d9-1bf7-43f8-8834-04c687184b57} PushingToViews: Failed to push block to view test_5.v1 (4ae2feef-b6fa-47ac-b20c-744da14b2a0a), Stack size too large. Stack address: 0x7fb7fddf0000, frame address: 0x7fb7fe1ef100, stack size: 4198144, maximum stack size: 8388608 2025.07.28 11:53:01.149580 [ 17207 ] {c88d86d9-1bf7-43f8-8834-04c687184b57} PushingToViews: Failed to push block to view test_5.v2 (7c22a887-3ed3-40f1-a092-d92463e4b87b), Stack size too large. Stack address: 0x7fb7fddf0000, frame address: 0x7fb7fe1ef100, stack size: 4198144, maximum stack size: 8388608 2025.07.28 11:53:01.157678 [ 17207 ] {c88d86d9-1bf7-43f8-8834-04c687184b57} PushingToViews: Failed to push block to view test_5.v1 (4ae2feef-b6fa-47ac-b20c-744da14b2a0a), Stack size too large. Stack address: 0x7fb7fddf0000, frame address: 0x7fb7fe1ef100, stack size: 4198144, maximum stack size: 8388608 2025.07.28 11:53:01.162693 [ 17207 ] {c88d86d9-1bf7-43f8-8834-04c687184b57} PushingToViews: Failed to push block to view test_5.v2 (7c22a887-3ed3-40f1-a092-d92463e4b87b), Stack size too large. Stack address: 0x7fb7fddf0000, frame address: 0x7fb7fe1ef100, stack size: 4198144, maximum stack size: 8388608 2025.07.28 11:53:01.176240 [ 17207 ] {c88d86d9-1bf7-43f8-8834-04c687184b57} PushingToViews: Failed to push block to view test_5.v1 (4ae2feef-b6fa-47ac-b20c-744da14b2a0a), Stack size too large. Stack address: 0x7fb7fddf0000, frame address: 0x7fb7fe1ef100, stack size: 4198144, maximum stack size: 8388608 2025.07.28 11:53:01.194252 [ 17207 ] {c88d86d9-1bf7-43f8-8834-04c687184b57} PushingToViews: Failed to push block to view test_5.v2 (7c22a887-3ed3-40f1-a092-d92463e4b87b), Stack size too large. Stack address: 0x7fb7fddf0000, frame address: 0x7fb7fe1ef100, stack size: 4198144, maximum stack size: 8388608 2025.07.28 11:53:01.195650 [ 17207 ] {c88d86d9-1bf7-43f8-8834-04c687184b57} PushingToViews: Failed to push block to view test_5.v1 (4ae2feef-b6fa-47ac-b20c-744da14b2a0a), Stack size too large. Stack address: 0x7fb7fddf0000, frame address: 0x7fb7fe1ef100, stack size: 4198144, maximum stack size: 8388608 2025.07.28 11:53:01.196640 [ 3974 ] {} test_13.rmt2 (7f9b740d-015c-470e-8cc6-8ba33be0dc63): auto DB::StorageReplicatedMergeTree::processQueueEntry(ReplicatedMergeTreeQueue::SelectedEntryPtr)::(anonymous class)::operator()(LogEntryPtr &) const: Code: 86. DB::HTTPException: Received error from remote server http://146b4357c08d:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Ftest%2F01165%2Ftest_13%2Frmt%2Freplicas%2F1&part=20250728_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.6.10636.altinitytest (altinity build)) '. (RECEIVED_ERROR_FROM_REMOTE_IO_SERVER), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.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 const&, int&&, String const&, unsigned long&&, String const&) @ 0x000000000feda8d9 4. /build/src/IO/HTTPCommon.cpp:104: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x000000000feda6e2 5. /build/src/IO/HTTPCommon.cpp:93: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x000000000feda537 6. /build/src/IO/ReadWriteBufferFromHTTP.cpp:277: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x000000001184a4c4 7. /build/src/IO/ReadWriteBufferFromHTTP.cpp:285: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x000000001184a615 8. /build/src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x000000001184ae59 9. /build/src/IO/ReadWriteBufferFromHTTP.cpp:472: void std::__function::__policy_invoker::__call_impl[abi:se190107]>(std::__function::__policy_storage const*) @ 0x000000001184cedd 10. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001184858b 11. /build/src/IO/ReadWriteBufferFromHTTP.cpp:465: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x000000001184bf0b 12. /build/src/IO/ReadBuffer.h:60: DB::ReadBuffer::next() @ 0x000000000a148c7b 13. /build/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) @ 0x0000000011849fb2 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]>&)>&, 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&) @ 0x0000000011841980 15. /build/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) @ 0x000000001621208e 16. /build/src/Storages/StorageReplicatedMergeTree.cpp:5228: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl[abi:se190107] const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000015f9a5fe 17. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000015ed8bfd 18. /build/src/Storages/StorageReplicatedMergeTree.cpp:2514: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x0000000015ec9aab 19. /build/src/Storages/StorageReplicatedMergeTree.cpp:2349: DB::StorageReplicatedMergeTree::executeLogEntry(DB::ReplicatedMergeTreeLogEntry&) @ 0x0000000015eba91b 20. /build/src/Storages/StorageReplicatedMergeTree.cpp:3876: bool std::__function::__policy_invoker&)>::__call_impl[abi:se190107])::$_1, bool (std::shared_ptr&)>>(std::__function::__policy_storage const*, std::shared_ptr&) @ 0x0000000015f9837e 21. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000165d6fc3 22. /build/src/Storages/StorageReplicatedMergeTree.cpp:3872: DB::StorageReplicatedMergeTree::processQueueEntry(std::shared_ptr) @ 0x0000000015efc18a 23. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001624c1b2 24. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000162f9c70 25. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x00000000162fa55a 26. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc6653 27. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000000fccc4c3 28. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc3d92 29. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fcca080 30. ? @ 0x00007fbc6213eac3 31. ? @ 0x00007fbc621d0850 (version 25.3.6.10636.altinitytest (altinity build)) 2025.07.28 11:53:01.197031 [ 17207 ] {c88d86d9-1bf7-43f8-8834-04c687184b57} PushingToViews: Failed to push block to view test_5.v2 (7c22a887-3ed3-40f1-a092-d92463e4b87b), Stack size too large. Stack address: 0x7fb7fddf0000, frame address: 0x7fb7fe1ef100, stack size: 4198144, maximum stack size: 8388608 2025.07.28 11:53:01.267809 [ 17207 ] {c88d86d9-1bf7-43f8-8834-04c687184b57} PushingToViews: Failed to push block to view test_5.v1 (4ae2feef-b6fa-47ac-b20c-744da14b2a0a), Stack size too large. Stack address: 0x7fb7fddf0000, frame address: 0x7fb7fe1ef100, stack size: 4198144, maximum stack size: 8388608 2025.07.28 11:53:01.275882 [ 17207 ] {c88d86d9-1bf7-43f8-8834-04c687184b57} PushingToViews: Failed to push block to view test_5.v2 (7c22a887-3ed3-40f1-a092-d92463e4b87b), Stack size too large. Stack address: 0x7fb7fddf0000, frame address: 0x7fb7fe1ef100, stack size: 4198144, maximum stack size: 8388608 2025.07.28 11:53:01.276610 [ 17207 ] {c88d86d9-1bf7-43f8-8834-04c687184b57} PushingToViews: Failed to push block to view test_5.v1 (4ae2feef-b6fa-47ac-b20c-744da14b2a0a), Stack size too large. Stack address: 0x7fb7fddf0000, frame address: 0x7fb7fe1ef100, stack size: 4198144, maximum stack size: 8388608 2025.07.28 11:53:01.277517 [ 17207 ] {c88d86d9-1bf7-43f8-8834-04c687184b57} PushingToViews: Failed to push block to view test_5.v2 (7c22a887-3ed3-40f1-a092-d92463e4b87b), Stack size too large. Stack address: 0x7fb7fddf0000, frame address: 0x7fb7fe1ef100, stack size: 4198144, maximum stack size: 8388608 2025.07.28 11:53:01.278303 [ 17207 ] {c88d86d9-1bf7-43f8-8834-04c687184b57} PushingToViews: Failed to push block to view test_5.v1 (4ae2feef-b6fa-47ac-b20c-744da14b2a0a), Stack size too large. Stack address: 0x7fb7fddf0000, frame address: 0x7fb7fe1ef100, stack size: 4198144, maximum stack size: 8388608 2025.07.28 11:53:01.279989 [ 17207 ] {c88d86d9-1bf7-43f8-8834-04c687184b57} PushingToViews: Failed to push block to view test_5.v2 (7c22a887-3ed3-40f1-a092-d92463e4b87b), Stack size too large. Stack address: 0x7fb7fddf0000, frame address: 0x7fb7fe1ef100, stack size: 4198144, maximum stack size: 8388608 2025.07.28 11:53:01.285404 [ 17207 ] {c88d86d9-1bf7-43f8-8834-04c687184b57} PushingToViews: Failed to push block to view test_5.v1 (4ae2feef-b6fa-47ac-b20c-744da14b2a0a), Stack size too large. Stack address: 0x7fb7fddf0000, frame address: 0x7fb7fe1ef100, stack size: 4198144, maximum stack size: 8388608 2025.07.28 11:53:01.287909 [ 17207 ] {c88d86d9-1bf7-43f8-8834-04c687184b57} PushingToViews: Failed to push block to view test_5.v2 (7c22a887-3ed3-40f1-a092-d92463e4b87b), Stack size too large. Stack address: 0x7fb7fddf0000, frame address: 0x7fb7fe1ef100, stack size: 4198144, maximum stack size: 8388608 2025.07.28 11:53:01.291286 [ 17207 ] {c88d86d9-1bf7-43f8-8834-04c687184b57} PushingToViews: Failed to push block to view test_5.v1 (4ae2feef-b6fa-47ac-b20c-744da14b2a0a), Stack size too large. Stack address: 0x7fb7fddf0000, frame address: 0x7fb7fe1ef100, stack size: 4198144, maximum stack size: 8388608 2025.07.28 11:53:01.294485 [ 17207 ] {c88d86d9-1bf7-43f8-8834-04c687184b57} PushingToViews: Failed to push block to view test_5.v2 (7c22a887-3ed3-40f1-a092-d92463e4b87b), Stack size too large. Stack address: 0x7fb7fddf0000, frame address: 0x7fb7fe1ef100, stack size: 4198144, maximum stack size: 8388608 2025.07.28 11:53:01.295947 [ 17207 ] {c88d86d9-1bf7-43f8-8834-04c687184b57} PushingToViews: Failed to push block to view test_5.v1 (4ae2feef-b6fa-47ac-b20c-744da14b2a0a), Stack size too large. Stack address: 0x7fb7fddf0000, frame address: 0x7fb7fe1ef100, stack size: 4198144, maximum stack size: 8388608 2025.07.28 11:53:01.298118 [ 17207 ] {c88d86d9-1bf7-43f8-8834-04c687184b57} PushingToViews: Failed to push block to view test_5.v2 (7c22a887-3ed3-40f1-a092-d92463e4b87b), Stack size too large. Stack address: 0x7fb7fddf0000, frame address: 0x7fb7fe1ef100, stack size: 4198144, maximum stack size: 8388608 2025.07.28 11:53:01.306184 [ 17207 ] {c88d86d9-1bf7-43f8-8834-04c687184b57} PushingToViews: Failed to push block to view test_5.v1 (4ae2feef-b6fa-47ac-b20c-744da14b2a0a), Stack size too large. Stack address: 0x7fb7fddf0000, frame address: 0x7fb7fe1ef100, stack size: 4198144, maximum stack size: 8388608 2025.07.28 11:53:01.313941 [ 17207 ] {c88d86d9-1bf7-43f8-8834-04c687184b57} PushingToViews: Failed to push block to view test_5.v2 (7c22a887-3ed3-40f1-a092-d92463e4b87b), Stack size too large. Stack address: 0x7fb7fddf0000, frame address: 0x7fb7fe1ef100, stack size: 4198144, maximum stack size: 8388608 2025.07.28 11:53:01.316405 [ 17207 ] {c88d86d9-1bf7-43f8-8834-04c687184b57} PushingToViews: Failed to push block to view test_5.v1 (4ae2feef-b6fa-47ac-b20c-744da14b2a0a), Stack size too large. Stack address: 0x7fb7fddf0000, frame address: 0x7fb7fe1ef100, stack size: 4198144, maximum stack size: 8388608 2025.07.28 11:53:01.327337 [ 17207 ] {c88d86d9-1bf7-43f8-8834-04c687184b57} PushingToViews: Failed to push block to view test_5.v2 (7c22a887-3ed3-40f1-a092-d92463e4b87b), Stack size too large. Stack address: 0x7fb7fddf0000, frame address: 0x7fb7fe1ef100, stack size: 4198144, maximum stack size: 8388608 2025.07.28 11:53:01.329215 [ 17207 ] {c88d86d9-1bf7-43f8-8834-04c687184b57} PushingToViews: Failed to push block to view test_5.v1 (4ae2feef-b6fa-47ac-b20c-744da14b2a0a), Stack size too large. Stack address: 0x7fb7fddf0000, frame address: 0x7fb7fe1ef100, stack size: 4198144, maximum stack size: 8388608 2025.07.28 11:53:01.351970 [ 17207 ] {c88d86d9-1bf7-43f8-8834-04c687184b57} PushingToViews: Failed to push block to view test_5.v2 (7c22a887-3ed3-40f1-a092-d92463e4b87b), Stack size too large. Stack address: 0x7fb7fddf0000, frame address: 0x7fb7fe1ef100, stack size: 4198144, maximum stack size: 8388608 2025.07.28 11:53:01.368271 [ 17207 ] {c88d86d9-1bf7-43f8-8834-04c687184b57} PushingToViews: Failed to push block to view test_5.v1 (4ae2feef-b6fa-47ac-b20c-744da14b2a0a), Stack size too large. Stack address: 0x7fb7fddf0000, frame address: 0x7fb7fe1ef100, stack size: 4198144, maximum stack size: 8388608 2025.07.28 11:53:01.394901 [ 17207 ] {c88d86d9-1bf7-43f8-8834-04c687184b57} PushingToViews: Failed to push block to view test_5.v2 (7c22a887-3ed3-40f1-a092-d92463e4b87b), Stack size too large. Stack address: 0x7fb7fddf0000, frame address: 0x7fb7fe1ef100, stack size: 4198144, maximum stack size: 8388608 2025.07.28 11:53:01.401782 [ 17207 ] {c88d86d9-1bf7-43f8-8834-04c687184b57} PushingToViews: Failed to push block to view test_5.v1 (4ae2feef-b6fa-47ac-b20c-744da14b2a0a), Stack size too large. Stack address: 0x7fb7fddf0000, frame address: 0x7fb7fe1ef100, stack size: 4198144, maximum stack size: 8388608 2025.07.28 11:53:01.413073 [ 17207 ] {c88d86d9-1bf7-43f8-8834-04c687184b57} PushingToViews: Failed to push block to view test_5.v2 (7c22a887-3ed3-40f1-a092-d92463e4b87b), Stack size too large. Stack address: 0x7fb7fddf0000, frame address: 0x7fb7fe1ef100, stack size: 4198144, maximum stack size: 8388608 2025.07.28 11:53:01.417096 [ 17207 ] {c88d86d9-1bf7-43f8-8834-04c687184b57} PushingToViews: Failed to push block to view test_5.v1 (4ae2feef-b6fa-47ac-b20c-744da14b2a0a), Stack size too large. Stack address: 0x7fb7fddf0000, frame address: 0x7fb7fe1ef100, stack size: 4198144, maximum stack size: 8388608 2025.07.28 11:53:01.420492 [ 17207 ] {c88d86d9-1bf7-43f8-8834-04c687184b57} PushingToViews: Failed to push block to view test_5.v2 (7c22a887-3ed3-40f1-a092-d92463e4b87b), Stack size too large. Stack address: 0x7fb7fddf0000, frame address: 0x7fb7fe1ef100, stack size: 4198144, maximum stack size: 8388608 2025.07.28 11:53:01.425384 [ 17207 ] {c88d86d9-1bf7-43f8-8834-04c687184b57} PushingToViews: Failed to push block to view test_5.v1 (4ae2feef-b6fa-47ac-b20c-744da14b2a0a), Stack size too large. Stack address: 0x7fb7fddf0000, frame address: 0x7fb7fe1ef100, stack size: 4198144, maximum stack size: 8388608 2025.07.28 11:53:01.431427 [ 17207 ] {c88d86d9-1bf7-43f8-8834-04c687184b57} PushingToViews: Failed to push block to view test_5.v2 (7c22a887-3ed3-40f1-a092-d92463e4b87b), Stack size too large. Stack address: 0x7fb7fddf0000, frame address: 0x7fb7fe1ef100, stack size: 4198144, maximum stack size: 8388608 2025.07.28 11:53:01.436392 [ 17207 ] {c88d86d9-1bf7-43f8-8834-04c687184b57} PushingToViews: Failed to push block to view test_5.v1 (4ae2feef-b6fa-47ac-b20c-744da14b2a0a), Stack size too large. Stack address: 0x7fb7fddf0000, frame address: 0x7fb7fe1ef100, stack size: 4198144, maximum stack size: 8388608 2025.07.28 11:53:01.439542 [ 17207 ] {c88d86d9-1bf7-43f8-8834-04c687184b57} PushingToViews: Failed to push block to view test_5.v2 (7c22a887-3ed3-40f1-a092-d92463e4b87b), Stack size too large. Stack address: 0x7fb7fddf0000, frame address: 0x7fb7fe1ef100, stack size: 4198144, maximum stack size: 8388608 2025.07.28 11:53:01.440799 [ 17207 ] {c88d86d9-1bf7-43f8-8834-04c687184b57} PushingToViews: Failed to push block to view test_5.v1 (4ae2feef-b6fa-47ac-b20c-744da14b2a0a), Stack size too large. Stack address: 0x7fb7fddf0000, frame address: 0x7fb7fe1ef100, stack size: 4198144, maximum stack size: 8388608 2025.07.28 11:53:01.443647 [ 17207 ] {c88d86d9-1bf7-43f8-8834-04c687184b57} PushingToViews: Failed to push block to view test_5.v2 (7c22a887-3ed3-40f1-a092-d92463e4b87b), Stack size too large. Stack address: 0x7fb7fddf0000, frame address: 0x7fb7fe1ef100, stack size: 4198144, maximum stack size: 8388608 2025.07.28 11:53:01.447942 [ 17207 ] {c88d86d9-1bf7-43f8-8834-04c687184b57} PushingToViews: Failed to push block to view test_5.v1 (4ae2feef-b6fa-47ac-b20c-744da14b2a0a), Stack size too large. Stack address: 0x7fb7fddf0000, frame address: 0x7fb7fe1ef100, stack size: 4198144, maximum stack size: 8388608 2025.07.28 11:53:01.452327 [ 17207 ] {c88d86d9-1bf7-43f8-8834-04c687184b57} PushingToViews: Failed to push block to view test_5.v2 (7c22a887-3ed3-40f1-a092-d92463e4b87b), Stack size too large. Stack address: 0x7fb7fddf0000, frame address: 0x7fb7fe1ef100, stack size: 4198144, maximum stack size: 8388608 2025.07.28 11:53:01.456866 [ 17207 ] {c88d86d9-1bf7-43f8-8834-04c687184b57} PushingToViews: Failed to push block to view test_5.v1 (4ae2feef-b6fa-47ac-b20c-744da14b2a0a), Stack size too large. Stack address: 0x7fb7fddf0000, frame address: 0x7fb7fe1ef100, stack size: 4198144, maximum stack size: 8388608 2025.07.28 11:53:01.459627 [ 17207 ] {c88d86d9-1bf7-43f8-8834-04c687184b57} PushingToViews: Failed to push block to view test_5.v2 (7c22a887-3ed3-40f1-a092-d92463e4b87b), Stack size too large. Stack address: 0x7fb7fddf0000, frame address: 0x7fb7fe1ef100, stack size: 4198144, maximum stack size: 8388608 2025.07.28 11:53:01.461838 [ 17207 ] {c88d86d9-1bf7-43f8-8834-04c687184b57} PushingToViews: Failed to push block to view test_5.v1 (4ae2feef-b6fa-47ac-b20c-744da14b2a0a), Stack size too large. Stack address: 0x7fb7fddf0000, frame address: 0x7fb7fe1ef100, stack size: 4198144, maximum stack size: 8388608 2025.07.28 11:53:01.463879 [ 17207 ] {c88d86d9-1bf7-43f8-8834-04c687184b57} PushingToViews: Failed to push block to view test_5.v2 (7c22a887-3ed3-40f1-a092-d92463e4b87b), Stack size too large. Stack address: 0x7fb7fddf0000, frame address: 0x7fb7fe1ef100, stack size: 4198144, maximum stack size: 8388608 2025.07.28 11:53:01.465172 [ 17207 ] {c88d86d9-1bf7-43f8-8834-04c687184b57} PushingToViews: Failed to push block to view test_5.v1 (4ae2feef-b6fa-47ac-b20c-744da14b2a0a), Stack size too large. Stack address: 0x7fb7fddf0000, frame address: 0x7fb7fe1ef100, stack size: 4198144, maximum stack size: 8388608 2025.07.28 11:53:01.471946 [ 17207 ] {c88d86d9-1bf7-43f8-8834-04c687184b57} PushingToViews: Failed to push block to view test_5.v2 (7c22a887-3ed3-40f1-a092-d92463e4b87b), Stack size too large. Stack address: 0x7fb7fddf0000, frame address: 0x7fb7fe1ef100, stack size: 4198144, maximum stack size: 8388608 2025.07.28 11:53:01.473455 [ 17207 ] {c88d86d9-1bf7-43f8-8834-04c687184b57} PushingToViews: Failed to push block to view test_5.v1 (4ae2feef-b6fa-47ac-b20c-744da14b2a0a), Stack size too large. Stack address: 0x7fb7fddf0000, frame address: 0x7fb7fe1ef100, stack size: 4198144, maximum stack size: 8388608 2025.07.28 11:53:01.491755 [ 17207 ] {c88d86d9-1bf7-43f8-8834-04c687184b57} PushingToViews: Failed to push block to view test_5.v2 (7c22a887-3ed3-40f1-a092-d92463e4b87b), Stack size too large. Stack address: 0x7fb7fddf0000, frame address: 0x7fb7fe1ef100, stack size: 4198144, maximum stack size: 8388608 2025.07.28 11:53:01.502230 [ 17207 ] {c88d86d9-1bf7-43f8-8834-04c687184b57} PushingToViews: Failed to push block to view test_5.v1 (4ae2feef-b6fa-47ac-b20c-744da14b2a0a), Stack size too large. Stack address: 0x7fb7fddf0000, frame address: 0x7fb7fe1ef100, stack size: 4198144, maximum stack size: 8388608 2025.07.28 11:53:01.503097 [ 17207 ] {c88d86d9-1bf7-43f8-8834-04c687184b57} PushingToViews: Failed to push block to view test_5.v2 (7c22a887-3ed3-40f1-a092-d92463e4b87b), Stack size too large. Stack address: 0x7fb7fddf0000, frame address: 0x7fb7fe1ef100, stack size: 4198144, maximum stack size: 8388608 2025.07.28 11:53:01.509710 [ 17207 ] {c88d86d9-1bf7-43f8-8834-04c687184b57} PushingToViews: Failed to push block to view test_5.v1 (4ae2feef-b6fa-47ac-b20c-744da14b2a0a), Stack size too large. Stack address: 0x7fb7fddf0000, frame address: 0x7fb7fe1ef100, stack size: 4198144, maximum stack size: 8388608 2025.07.28 11:53:01.510694 [ 17207 ] {c88d86d9-1bf7-43f8-8834-04c687184b57} PushingToViews: Failed to push block to view test_5.v2 (7c22a887-3ed3-40f1-a092-d92463e4b87b), Stack size too large. Stack address: 0x7fb7fddf0000, frame address: 0x7fb7fe1ef100, stack size: 4198144, maximum stack size: 8388608 2025.07.28 11:53:01.512335 [ 17207 ] {c88d86d9-1bf7-43f8-8834-04c687184b57} PushingToViews: Failed to push block to view test_5.v1 (4ae2feef-b6fa-47ac-b20c-744da14b2a0a), Stack size too large. Stack address: 0x7fb7fddf0000, frame address: 0x7fb7fe1ef100, stack size: 4198144, maximum stack size: 8388608 2025.07.28 11:53:01.514124 [ 17207 ] {c88d86d9-1bf7-43f8-8834-04c687184b57} PushingToViews: Failed to push block to view test_5.v2 (7c22a887-3ed3-40f1-a092-d92463e4b87b), Stack size too large. Stack address: 0x7fb7fddf0000, frame address: 0x7fb7fe1ef100, stack size: 4198144, maximum stack size: 8388608 2025.07.28 11:53:01.515708 [ 17207 ] {c88d86d9-1bf7-43f8-8834-04c687184b57} PushingToViews: Failed to push block to view test_5.v1 (4ae2feef-b6fa-47ac-b20c-744da14b2a0a), Stack size too large. Stack address: 0x7fb7fddf0000, frame address: 0x7fb7fe1ef100, stack size: 4198144, maximum stack size: 8388608 2025.07.28 11:53:01.601281 [ 17207 ] {c88d86d9-1bf7-43f8-8834-04c687184b57} executeQuery: Code: 306. DB::Exception: Stack size too large. Stack address: 0x7fb7fddf0000, frame address: 0x7fb7fe1ef100, stack size: 4198144, maximum stack size: 8388608. (TOO_DEEP_RECURSION) (version 25.3.6.10636.altinitytest (altinity build)) (from [::1]:56256) (comment: 01527_materialized_view_stack_overflow.sql) (query 15, line 21) (in query: INSERT INTO t2 VALUES ), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, void*&, void const*&, unsigned long&, unsigned long&) @ 0x000000000fc5a24b 4. /build/src/Common/checkStackSize.cpp:151: checkStackSize() @ 0x000000000fc5a14c 5. /build/src/Interpreters/DatabaseCatalog.cpp:338: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x00000000144f0432 6. /build/src/Interpreters/DatabaseCatalog.cpp:984: DB::DatabaseCatalog::tryGetTable(DB::StorageID const&, std::shared_ptr) const @ 0x00000000144f6b77 7. /build/src/Analyzer/Resolve/IdentifierResolver.cpp:177: DB::IdentifierResolver::tryResolveTableIdentifierFromDatabaseCatalog(DB::Identifier const&, std::shared_ptr const&) @ 0x00000000142b9931 8. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:1550: DB::QueryAnalyzer::tryResolveIdentifier(DB::IdentifierLookup const&, DB::IdentifierResolveScope&, DB::IdentifierResolveContext) @ 0x00000000140299a0 9. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:4365: DB::QueryAnalyzer::initializeQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000014043a79 10. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5594: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000140135fb 11. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000140127f9 12. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000014011fce 13. /build/src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000001406ce8a 14. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000014973b42 15. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000001497268d 16. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:205: DB::InterpreterSelectQueryAnalyzer::getSampleBlock(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000014973e7b 17. /build/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) @ 0x0000000016caf5d9 18. /build/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&) @ 0x0000000016cb34a8 19. /build/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*) @ 0x000000001492df0b 20. /build/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) @ 0x000000001492d92e 21. /build/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) @ 0x0000000016cb086b 22. /build/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&) @ 0x0000000016cb34a8 23. /build/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*) @ 0x000000001492df0b 24. /build/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) @ 0x000000001492d92e 25. /build/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) @ 0x0000000016cb086b 26. /build/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&) @ 0x0000000016cb34a8 27. /build/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*) @ 0x000000001492df0b 28. /build/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) @ 0x000000001492d92e 29. /build/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) @ 0x0000000016cb086b 30. /build/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&) @ 0x0000000016cb34a8 31. /build/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*) @ 0x000000001492df0b 2025.07.28 11:53:01.627012 [ 17207 ] {} TCPHandler: Code: 306. DB::Exception: Stack size too large. Stack address: 0x7fb7fddf0000, frame address: 0x7fb7fe1ef100, stack size: 4198144, maximum stack size: 8388608. (TOO_DEEP_RECURSION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, void*&, void const*&, unsigned long&, unsigned long&) @ 0x000000000fc5a24b 4. /build/src/Common/checkStackSize.cpp:151: checkStackSize() @ 0x000000000fc5a14c 5. /build/src/Interpreters/DatabaseCatalog.cpp:338: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x00000000144f0432 6. /build/src/Interpreters/DatabaseCatalog.cpp:984: DB::DatabaseCatalog::tryGetTable(DB::StorageID const&, std::shared_ptr) const @ 0x00000000144f6b77 7. /build/src/Analyzer/Resolve/IdentifierResolver.cpp:177: DB::IdentifierResolver::tryResolveTableIdentifierFromDatabaseCatalog(DB::Identifier const&, std::shared_ptr const&) @ 0x00000000142b9931 8. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:1550: DB::QueryAnalyzer::tryResolveIdentifier(DB::IdentifierLookup const&, DB::IdentifierResolveScope&, DB::IdentifierResolveContext) @ 0x00000000140299a0 9. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:4365: DB::QueryAnalyzer::initializeQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000014043a79 10. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5594: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000140135fb 11. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000140127f9 12. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000014011fce 13. /build/src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000001406ce8a 14. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000014973b42 15. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000001497268d 16. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:205: DB::InterpreterSelectQueryAnalyzer::getSampleBlock(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000014973e7b 17. /build/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) @ 0x0000000016caf5d9 18. /build/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&) @ 0x0000000016cb34a8 19. /build/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*) @ 0x000000001492df0b 20. /build/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) @ 0x000000001492d92e 21. /build/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) @ 0x0000000016cb086b 22. /build/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&) @ 0x0000000016cb34a8 23. /build/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*) @ 0x000000001492df0b 24. /build/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) @ 0x000000001492d92e 25. /build/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) @ 0x0000000016cb086b 26. /build/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&) @ 0x0000000016cb34a8 27. /build/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*) @ 0x000000001492df0b 28. /build/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) @ 0x000000001492d92e 29. /build/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) @ 0x0000000016cb086b 30. /build/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&) @ 0x0000000016cb34a8 31. /build/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*) @ 0x000000001492df0b 2025.07.28 11:53:01.645257 [ 3287 ] {a8d8fb4c-cf18-4080-8b98-f7f7f270c0ce} executeQuery: Code: 111. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(1_Bool :: 1, 'error_log'_String :: 2, _CAST(111_Int16, 'Int16'_String) :: 3) -> throwIf(1_Bool, 'error_log'_String, _CAST(111_Int16, 'Int16'_String)) UInt8 : 4'. (CANNOT_MANIPULATE_SIGSET) (version 25.3.6.10636.altinitytest (altinity build)) (from [::1]:34222) (comment: 03172_error_log_table_not_empty.sh) (query 1, line 2) (in query: SELECT throwIf(true, 'error_log', toInt16(111)) SETTINGS allow_custom_error_code_in_throwif=1;), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x000000000a06b56b 4. /build/src/Functions/throwIf.cpp:153: DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000e8193b5 5. /build/src/Functions/IFunctionAdaptors.cpp:10: DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000012d995fa 6. /build/src/Functions/IFunction.cpp:353: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d93b52 7. /build/src/Functions/IFunction.cpp:420: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d95059 8. /build/src/Functions/IFunction.cpp:498: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d95c72 9. /build/src/Interpreters/ExpressionActions.cpp:636: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x00000000145176f3 10. /build/src/Processors/Transforms/ExpressionTransform.cpp:25: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x0000000016c0b34c 11. /build/src/Processors/ISimpleTransform.h:33: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000011a9a453 12. /build/src/Processors/ISimpleTransform.cpp:89: DB::ISimpleTransform::work() @ 0x000000001699fca0 13. /build/src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x00000000169bd00f 14. /build/src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x00000000169b2105 15. /build/src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeSingleThread(unsigned long) @ 0x00000000169b23be 16. /build/src/Processors/Executors/PipelineExecutor.cpp:454: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x00000000169b0be7 17. /build/src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x00000000169b03f4 18. /build/src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:se190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169bfeab 19. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc3d92 20. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fcca080 21. ? @ 0x00007fbc6213eac3 22. ? @ 0x00007fbc621d0850 2025.07.28 11:53:01.656901 [ 3287 ] {} TCPHandler: Code: 111. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(1_Bool :: 1, 'error_log'_String :: 2, _CAST(111_Int16, 'Int16'_String) :: 3) -> throwIf(1_Bool, 'error_log'_String, _CAST(111_Int16, 'Int16'_String)) UInt8 : 4'. (CANNOT_MANIPULATE_SIGSET), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x000000000a06b56b 4. /build/src/Functions/throwIf.cpp:153: DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000e8193b5 5. /build/src/Functions/IFunctionAdaptors.cpp:10: DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000012d995fa 6. /build/src/Functions/IFunction.cpp:353: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d93b52 7. /build/src/Functions/IFunction.cpp:420: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d95059 8. /build/src/Functions/IFunction.cpp:498: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d95c72 9. /build/src/Interpreters/ExpressionActions.cpp:636: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x00000000145176f3 10. /build/src/Processors/Transforms/ExpressionTransform.cpp:25: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x0000000016c0b34c 11. /build/src/Processors/ISimpleTransform.h:33: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000011a9a453 12. /build/src/Processors/ISimpleTransform.cpp:89: DB::ISimpleTransform::work() @ 0x000000001699fca0 13. /build/src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x00000000169bd00f 14. /build/src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x00000000169b2105 15. /build/src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeSingleThread(unsigned long) @ 0x00000000169b23be 16. /build/src/Processors/Executors/PipelineExecutor.cpp:454: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x00000000169b0be7 17. /build/src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x00000000169b03f4 18. /build/src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:se190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169bfeab 19. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc3d92 20. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fcca080 21. ? @ 0x00007fbc6213eac3 22. ? @ 0x00007fbc621d0850 Job's origin stack trace: 0. /build/src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000000fc33b84 1. /build/src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000000fcc2ea7 2. /build/src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fcc535c 3. /build/src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000000fcc584d 4. /build/src/Common/ThreadPool.h:279: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x00000000169bf193 5. /build/src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x00000000169bf518 6. /build/src/Server/TCPHandler.cpp:1237: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x00000000168f1525 7. /build/src/Server/TCPHandler.cpp:678: DB::TCPHandler::runImpl() @ 0x00000000168e68e5 8. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 9. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 10. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 11. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 12. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 13. ? @ 0x00007fbc6213eac3 14. ? @ 0x00007fbc621d0850 2025.07.28 11:53:01.790047 [ 3287 ] {0a611685-cdc9-4677-8743-67405df04be8} executeQuery: Code: 222. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(1_Bool :: 1, 'error_log'_String :: 2, _CAST(222_Int16, 'Int16'_String) :: 3) -> throwIf(1_Bool, 'error_log'_String, _CAST(222_Int16, 'Int16'_String)) UInt8 : 4'. () (version 25.3.6.10636.altinitytest (altinity build)) (from [::1]:34222) (comment: 03172_error_log_table_not_empty.sh) (query 2, line 3) (in query: SELECT throwIf(true, 'error_log', toInt16(222)) SETTINGS allow_custom_error_code_in_throwif=1;), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x000000000a06b56b 4. /build/src/Functions/throwIf.cpp:153: DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000e8193b5 5. /build/src/Functions/IFunctionAdaptors.cpp:10: DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000012d995fa 6. /build/src/Functions/IFunction.cpp:353: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d93b52 7. /build/src/Functions/IFunction.cpp:420: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d95059 8. /build/src/Functions/IFunction.cpp:498: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d95c72 9. /build/src/Interpreters/ExpressionActions.cpp:636: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x00000000145176f3 10. /build/src/Processors/Transforms/ExpressionTransform.cpp:25: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x0000000016c0b34c 11. /build/src/Processors/ISimpleTransform.h:33: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000011a9a453 12. /build/src/Processors/ISimpleTransform.cpp:89: DB::ISimpleTransform::work() @ 0x000000001699fca0 13. /build/src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x00000000169bd00f 14. /build/src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x00000000169b2105 15. /build/src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeSingleThread(unsigned long) @ 0x00000000169b23be 16. /build/src/Processors/Executors/PipelineExecutor.cpp:454: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x00000000169b0be7 17. /build/src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x00000000169b03f4 18. /build/src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:se190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169bfeab 19. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc3d92 20. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fcca080 21. ? @ 0x00007fbc6213eac3 22. ? @ 0x00007fbc621d0850 2025.07.28 11:53:01.797262 [ 3287 ] {} TCPHandler: Code: 222. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(1_Bool :: 1, 'error_log'_String :: 2, _CAST(222_Int16, 'Int16'_String) :: 3) -> throwIf(1_Bool, 'error_log'_String, _CAST(222_Int16, 'Int16'_String)) UInt8 : 4'. (), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x000000000a06b56b 4. /build/src/Functions/throwIf.cpp:153: DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000e8193b5 5. /build/src/Functions/IFunctionAdaptors.cpp:10: DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000012d995fa 6. /build/src/Functions/IFunction.cpp:353: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d93b52 7. /build/src/Functions/IFunction.cpp:420: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d95059 8. /build/src/Functions/IFunction.cpp:498: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d95c72 9. /build/src/Interpreters/ExpressionActions.cpp:636: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x00000000145176f3 10. /build/src/Processors/Transforms/ExpressionTransform.cpp:25: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x0000000016c0b34c 11. /build/src/Processors/ISimpleTransform.h:33: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000011a9a453 12. /build/src/Processors/ISimpleTransform.cpp:89: DB::ISimpleTransform::work() @ 0x000000001699fca0 13. /build/src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x00000000169bd00f 14. /build/src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x00000000169b2105 15. /build/src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeSingleThread(unsigned long) @ 0x00000000169b23be 16. /build/src/Processors/Executors/PipelineExecutor.cpp:454: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x00000000169b0be7 17. /build/src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x00000000169b03f4 18. /build/src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:se190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169bfeab 19. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc3d92 20. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fcca080 21. ? @ 0x00007fbc6213eac3 22. ? @ 0x00007fbc621d0850 Job's origin stack trace: 0. /build/src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000000fc33b84 1. /build/src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000000fcc2ea7 2. /build/src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fcc535c 3. /build/src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000000fcc584d 4. /build/src/Common/ThreadPool.h:279: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x00000000169bf193 5. /build/src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x00000000169bf518 6. /build/src/Server/TCPHandler.cpp:1237: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x00000000168f1525 7. /build/src/Server/TCPHandler.cpp:678: DB::TCPHandler::runImpl() @ 0x00000000168e68e5 8. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 9. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 10. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 11. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 12. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 13. ? @ 0x00007fbc6213eac3 14. ? @ 0x00007fbc621d0850 2025.07.28 11:53:01.860820 [ 3287 ] {09f87be6-5313-4438-9559-9d1324aa853d} executeQuery: Code: 333. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(1_Bool :: 1, 'error_log'_String :: 2, _CAST(333_Int16, 'Int16'_String) :: 3) -> throwIf(1_Bool, 'error_log'_String, _CAST(333_Int16, 'Int16'_String)) UInt8 : 4'. () (version 25.3.6.10636.altinitytest (altinity build)) (from [::1]:34222) (comment: 03172_error_log_table_not_empty.sh) (query 3, line 4) (in query: SELECT throwIf(true, 'error_log', toInt16(333)) SETTINGS allow_custom_error_code_in_throwif=1;), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x000000000a06b56b 4. /build/src/Functions/throwIf.cpp:153: DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000e8193b5 5. /build/src/Functions/IFunctionAdaptors.cpp:10: DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000012d995fa 6. /build/src/Functions/IFunction.cpp:353: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d93b52 7. /build/src/Functions/IFunction.cpp:420: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d95059 8. /build/src/Functions/IFunction.cpp:498: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d95c72 9. /build/src/Interpreters/ExpressionActions.cpp:636: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x00000000145176f3 10. /build/src/Processors/Transforms/ExpressionTransform.cpp:25: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x0000000016c0b34c 11. /build/src/Processors/ISimpleTransform.h:33: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000011a9a453 12. /build/src/Processors/ISimpleTransform.cpp:89: DB::ISimpleTransform::work() @ 0x000000001699fca0 13. /build/src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x00000000169bd00f 14. /build/src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x00000000169b2105 15. /build/src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeSingleThread(unsigned long) @ 0x00000000169b23be 16. /build/src/Processors/Executors/PipelineExecutor.cpp:454: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x00000000169b0be7 17. /build/src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x00000000169b03f4 18. /build/src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:se190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169bfeab 19. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc3d92 20. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fcca080 21. ? @ 0x00007fbc6213eac3 22. ? @ 0x00007fbc621d0850 2025.07.28 11:53:01.864546 [ 3287 ] {} TCPHandler: Code: 333. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(1_Bool :: 1, 'error_log'_String :: 2, _CAST(333_Int16, 'Int16'_String) :: 3) -> throwIf(1_Bool, 'error_log'_String, _CAST(333_Int16, 'Int16'_String)) UInt8 : 4'. (), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x000000000a06b56b 4. /build/src/Functions/throwIf.cpp:153: DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000e8193b5 5. /build/src/Functions/IFunctionAdaptors.cpp:10: DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000012d995fa 6. /build/src/Functions/IFunction.cpp:353: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d93b52 7. /build/src/Functions/IFunction.cpp:420: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d95059 8. /build/src/Functions/IFunction.cpp:498: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d95c72 9. /build/src/Interpreters/ExpressionActions.cpp:636: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x00000000145176f3 10. /build/src/Processors/Transforms/ExpressionTransform.cpp:25: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x0000000016c0b34c 11. /build/src/Processors/ISimpleTransform.h:33: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000011a9a453 12. /build/src/Processors/ISimpleTransform.cpp:89: DB::ISimpleTransform::work() @ 0x000000001699fca0 13. /build/src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x00000000169bd00f 14. /build/src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x00000000169b2105 15. /build/src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeSingleThread(unsigned long) @ 0x00000000169b23be 16. /build/src/Processors/Executors/PipelineExecutor.cpp:454: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x00000000169b0be7 17. /build/src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x00000000169b03f4 18. /build/src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:se190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169bfeab 19. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc3d92 20. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fcca080 21. ? @ 0x00007fbc6213eac3 22. ? @ 0x00007fbc621d0850 Job's origin stack trace: 0. /build/src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000000fc33b84 1. /build/src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000000fcc2ea7 2. /build/src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fcc535c 3. /build/src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000000fcc584d 4. /build/src/Common/ThreadPool.h:279: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x00000000169bf193 5. /build/src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x00000000169bf518 6. /build/src/Server/TCPHandler.cpp:1237: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x00000000168f1525 7. /build/src/Server/TCPHandler.cpp:678: DB::TCPHandler::runImpl() @ 0x00000000168e68e5 8. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 9. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 10. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 11. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 12. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 13. ? @ 0x00007fbc6213eac3 14. ? @ 0x00007fbc621d0850 2025.07.28 11:53:02.249583 [ 3977 ] {} test_13.rmt2 (7f9b740d-015c-470e-8cc6-8ba33be0dc63): auto DB::StorageReplicatedMergeTree::processQueueEntry(ReplicatedMergeTreeQueue::SelectedEntryPtr)::(anonymous class)::operator()(LogEntryPtr &) const: Code: 86. DB::HTTPException: Received error from remote server http://146b4357c08d:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Ftest%2F01165%2Ftest_13%2Frmt%2Freplicas%2F1&part=20250728_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.6.10636.altinitytest (altinity build)) '. (RECEIVED_ERROR_FROM_REMOTE_IO_SERVER), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.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 const&, int&&, String const&, unsigned long&&, String const&) @ 0x000000000feda8d9 4. /build/src/IO/HTTPCommon.cpp:104: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x000000000feda6e2 5. /build/src/IO/HTTPCommon.cpp:93: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x000000000feda537 6. /build/src/IO/ReadWriteBufferFromHTTP.cpp:277: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x000000001184a4c4 7. /build/src/IO/ReadWriteBufferFromHTTP.cpp:285: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x000000001184a615 8. /build/src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x000000001184ae59 9. /build/src/IO/ReadWriteBufferFromHTTP.cpp:472: void std::__function::__policy_invoker::__call_impl[abi:se190107]>(std::__function::__policy_storage const*) @ 0x000000001184cedd 10. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001184858b 11. /build/src/IO/ReadWriteBufferFromHTTP.cpp:465: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x000000001184bf0b 12. /build/src/IO/ReadBuffer.h:60: DB::ReadBuffer::next() @ 0x000000000a148c7b 13. /build/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) @ 0x0000000011849fb2 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]>&)>&, 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&) @ 0x0000000011841980 15. /build/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) @ 0x000000001621208e 16. /build/src/Storages/StorageReplicatedMergeTree.cpp:5228: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl[abi:se190107] const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000015f9a5fe 17. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000015ed8bfd 18. /build/src/Storages/StorageReplicatedMergeTree.cpp:2514: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x0000000015ec9aab 19. /build/src/Storages/StorageReplicatedMergeTree.cpp:2349: DB::StorageReplicatedMergeTree::executeLogEntry(DB::ReplicatedMergeTreeLogEntry&) @ 0x0000000015eba91b 20. /build/src/Storages/StorageReplicatedMergeTree.cpp:3876: bool std::__function::__policy_invoker&)>::__call_impl[abi:se190107])::$_1, bool (std::shared_ptr&)>>(std::__function::__policy_storage const*, std::shared_ptr&) @ 0x0000000015f9837e 21. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000165d6fc3 22. /build/src/Storages/StorageReplicatedMergeTree.cpp:3872: DB::StorageReplicatedMergeTree::processQueueEntry(std::shared_ptr) @ 0x0000000015efc18a 23. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001624c1b2 24. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000162f9c70 25. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x00000000162fa55a 26. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc6653 27. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000000fccc4c3 28. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc3d92 29. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fcca080 30. ? @ 0x00007fbc6213eac3 31. ? @ 0x00007fbc621d0850 (version 25.3.6.10636.altinitytest (altinity build)) 2025.07.28 11:53:02.504560 [ 5879 ] {44a7c49b-34c5-4485-96a4-36f74245d314} executeQuery: Code: 47. DB::Exception: Unknown expression or function identifier `x` in scope x = 1. (UNKNOWN_IDENTIFIER) (version 25.3.6.10636.altinitytest (altinity build)) (from [::1]:34260) (comment: 03279_not_empty_json.sql) (query 4, line 5) (in query: select json, notEmpty(json) from test;), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.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&&) @ 0x000000001404b3b9 4. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3771: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000001401b849 5. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3980: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000014018e31 6. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:2925: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000001402fcbd 7. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3838: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000014019a9e 8. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:209: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000001401270e 9. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000014011fce 10. /build/src/Planner/Utils.cpp:458: DB::buildFilterInfo(std::shared_ptr, std::shared_ptr const&, std::shared_ptr&, std::unordered_set, std::equal_to, std::allocator>) @ 0x0000000013fe8bcf 11. /build/src/Planner/PlannerJoinTree.cpp:535: DB::(anonymous namespace)::buildQueryPlanForTableExpression(std::shared_ptr, std::shared_ptr const&, DB::SelectQueryInfo const&, DB::SelectQueryOptions const&, std::shared_ptr&, bool, bool) @ 0x00000000149956d3 12. /build/src/Planner/PlannerJoinTree.cpp:2252: DB::buildJoinTreeQueryPlan(std::shared_ptr const&, DB::SelectQueryInfo const&, DB::SelectQueryOptions&, std::unordered_set, std::equal_to, std::allocator> const&, std::shared_ptr&) @ 0x000000001498e109 13. /build/src/Planner/Planner.cpp:1553: DB::Planner::buildPlanForQueryNode() @ 0x0000000014979dae 14. /build/src/Planner/Planner.cpp:1308: DB::Planner::buildQueryPlanIfNeeded() @ 0x000000001497685c 15. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:255: DB::InterpreterSelectQueryAnalyzer::getQueryPlan() @ 0x000000001497476d 16. /build/src/Interpreters/executeQuery.cpp:1405: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88806 17. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 18. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 19. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 20. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 21. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 22. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 23. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 24. ? @ 0x00007fbc6213eac3 25. ? @ 0x00007fbc621d0850 2025.07.28 11:53:02.511886 [ 5879 ] {} TCPHandler: Code: 47. DB::Exception: Unknown expression or function identifier `x` in scope x = 1. (UNKNOWN_IDENTIFIER), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.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&&) @ 0x000000001404b3b9 4. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3771: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000001401b849 5. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3980: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000014018e31 6. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:2925: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000001402fcbd 7. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3838: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000014019a9e 8. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:209: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000001401270e 9. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000014011fce 10. /build/src/Planner/Utils.cpp:458: DB::buildFilterInfo(std::shared_ptr, std::shared_ptr const&, std::shared_ptr&, std::unordered_set, std::equal_to, std::allocator>) @ 0x0000000013fe8bcf 11. /build/src/Planner/PlannerJoinTree.cpp:535: DB::(anonymous namespace)::buildQueryPlanForTableExpression(std::shared_ptr, std::shared_ptr const&, DB::SelectQueryInfo const&, DB::SelectQueryOptions const&, std::shared_ptr&, bool, bool) @ 0x00000000149956d3 12. /build/src/Planner/PlannerJoinTree.cpp:2252: DB::buildJoinTreeQueryPlan(std::shared_ptr const&, DB::SelectQueryInfo const&, DB::SelectQueryOptions&, std::unordered_set, std::equal_to, std::allocator> const&, std::shared_ptr&) @ 0x000000001498e109 13. /build/src/Planner/Planner.cpp:1553: DB::Planner::buildPlanForQueryNode() @ 0x0000000014979dae 14. /build/src/Planner/Planner.cpp:1308: DB::Planner::buildQueryPlanIfNeeded() @ 0x000000001497685c 15. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:255: DB::InterpreterSelectQueryAnalyzer::getQueryPlan() @ 0x000000001497476d 16. /build/src/Interpreters/executeQuery.cpp:1405: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88806 17. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 18. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 19. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 20. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 21. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 22. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 23. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 24. ? @ 0x00007fbc6213eac3 25. ? @ 0x00007fbc621d0850 2025.07.28 11:53:02.531933 [ 3970 ] {} test_13.rmt2 (7f9b740d-015c-470e-8cc6-8ba33be0dc63): auto DB::StorageReplicatedMergeTree::processQueueEntry(ReplicatedMergeTreeQueue::SelectedEntryPtr)::(anonymous class)::operator()(LogEntryPtr &) const: Code: 86. DB::HTTPException: Received error from remote server http://146b4357c08d:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Ftest%2F01165%2Ftest_13%2Frmt%2Freplicas%2F1&part=20250728_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.6.10636.altinitytest (altinity build)) '. (RECEIVED_ERROR_FROM_REMOTE_IO_SERVER), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.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 const&, int&&, String const&, unsigned long&&, String const&) @ 0x000000000feda8d9 4. /build/src/IO/HTTPCommon.cpp:104: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x000000000feda6e2 5. /build/src/IO/HTTPCommon.cpp:93: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x000000000feda537 6. /build/src/IO/ReadWriteBufferFromHTTP.cpp:277: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x000000001184a4c4 7. /build/src/IO/ReadWriteBufferFromHTTP.cpp:285: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x000000001184a615 8. /build/src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x000000001184ae59 9. /build/src/IO/ReadWriteBufferFromHTTP.cpp:472: void std::__function::__policy_invoker::__call_impl[abi:se190107]>(std::__function::__policy_storage const*) @ 0x000000001184cedd 10. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001184858b 11. /build/src/IO/ReadWriteBufferFromHTTP.cpp:465: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x000000001184bf0b 12. /build/src/IO/ReadBuffer.h:60: DB::ReadBuffer::next() @ 0x000000000a148c7b 13. /build/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) @ 0x0000000011849fb2 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]>&)>&, 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&) @ 0x0000000011841980 15. /build/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) @ 0x000000001621208e 16. /build/src/Storages/StorageReplicatedMergeTree.cpp:5228: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl[abi:se190107] const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000015f9a5fe 17. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000015ed8bfd 18. /build/src/Storages/StorageReplicatedMergeTree.cpp:2514: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x0000000015ec9aab 19. /build/src/Storages/StorageReplicatedMergeTree.cpp:2349: DB::StorageReplicatedMergeTree::executeLogEntry(DB::ReplicatedMergeTreeLogEntry&) @ 0x0000000015eba91b 20. /build/src/Storages/StorageReplicatedMergeTree.cpp:3876: bool std::__function::__policy_invoker&)>::__call_impl[abi:se190107])::$_1, bool (std::shared_ptr&)>>(std::__function::__policy_storage const*, std::shared_ptr&) @ 0x0000000015f9837e 21. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000165d6fc3 22. /build/src/Storages/StorageReplicatedMergeTree.cpp:3872: DB::StorageReplicatedMergeTree::processQueueEntry(std::shared_ptr) @ 0x0000000015efc18a 23. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001624c1b2 24. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000162f9c70 25. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x00000000162fa55a 26. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc6653 27. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000000fccc4c3 28. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc3d92 29. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fcca080 30. ? @ 0x00007fbc6213eac3 31. ? @ 0x00007fbc621d0850 (version 25.3.6.10636.altinitytest (altinity build)) 2025.07.28 11:53:02.689619 [ 4900 ] {} 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. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception>&, String>(int, FormatStringHelperImpl>&>::type, std::type_identity::type>, std::basic_string_view>&, String&&) @ 0x000000001385a5eb 4. /build/src/Access/SettingsConstraints.cpp:376: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000013859b18 5. /build/src/Access/SettingsConstraints.cpp:300: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000013858faf 6. /build/src/Access/SettingsConstraints.cpp:209: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000013859223 7. /build/src/Interpreters/Context.cpp:2690: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000014436134 8. /build/src/Interpreters/Context.cpp:2729: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x000000001443662b 9. /build/src/Server/HTTPHandler.cpp:457: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000001686d165 10. /build/src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x0000000016870807 11. /build/src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x0000000016907e99 12. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 13. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 14. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 15. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 16. ? @ 0x00007fbc6213eac3 17. ? @ 0x00007fbc621d0850 (version 25.3.6.10636.altinitytest (altinity build)) 2025.07.28 11:53:02.761708 [ 3964 ] {} test_13.rmt2 (7f9b740d-015c-470e-8cc6-8ba33be0dc63): auto DB::StorageReplicatedMergeTree::processQueueEntry(ReplicatedMergeTreeQueue::SelectedEntryPtr)::(anonymous class)::operator()(LogEntryPtr &) const: Code: 86. DB::HTTPException: Received error from remote server http://146b4357c08d:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Ftest%2F01165%2Ftest_13%2Frmt%2Freplicas%2F1&part=20250728_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.6.10636.altinitytest (altinity build)) '. (RECEIVED_ERROR_FROM_REMOTE_IO_SERVER), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.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 const&, int&&, String const&, unsigned long&&, String const&) @ 0x000000000feda8d9 4. /build/src/IO/HTTPCommon.cpp:104: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x000000000feda6e2 5. /build/src/IO/HTTPCommon.cpp:93: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x000000000feda537 6. /build/src/IO/ReadWriteBufferFromHTTP.cpp:277: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x000000001184a4c4 7. /build/src/IO/ReadWriteBufferFromHTTP.cpp:285: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x000000001184a615 8. /build/src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x000000001184ae59 9. /build/src/IO/ReadWriteBufferFromHTTP.cpp:472: void std::__function::__policy_invoker::__call_impl[abi:se190107]>(std::__function::__policy_storage const*) @ 0x000000001184cedd 10. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001184858b 11. /build/src/IO/ReadWriteBufferFromHTTP.cpp:465: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x000000001184bf0b 12. /build/src/IO/ReadBuffer.h:60: DB::ReadBuffer::next() @ 0x000000000a148c7b 13. /build/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) @ 0x0000000011849fb2 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]>&)>&, 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&) @ 0x0000000011841980 15. /build/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) @ 0x000000001621208e 16. /build/src/Storages/StorageReplicatedMergeTree.cpp:5228: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl[abi:se190107] const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000015f9a5fe 17. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000015ed8bfd 18. /build/src/Storages/StorageReplicatedMergeTree.cpp:2514: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x0000000015ec9aab 19. /build/src/Storages/StorageReplicatedMergeTree.cpp:2349: DB::StorageReplicatedMergeTree::executeLogEntry(DB::ReplicatedMergeTreeLogEntry&) @ 0x0000000015eba91b 20. /build/src/Storages/StorageReplicatedMergeTree.cpp:3876: bool std::__function::__policy_invoker&)>::__call_impl[abi:se190107])::$_1, bool (std::shared_ptr&)>>(std::__function::__policy_storage const*, std::shared_ptr&) @ 0x0000000015f9837e 21. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000165d6fc3 22. /build/src/Storages/StorageReplicatedMergeTree.cpp:3872: DB::StorageReplicatedMergeTree::processQueueEntry(std::shared_ptr) @ 0x0000000015efc18a 23. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001624c1b2 24. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000162f9c70 25. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x00000000162fa55a 26. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc6653 27. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000000fccc4c3 28. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc3d92 29. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fcca080 30. ? @ 0x00007fbc6213eac3 31. ? @ 0x00007fbc621d0850 (version 25.3.6.10636.altinitytest (altinity build)) 2025.07.28 11:53:03.487961 [ 5879 ] {c1c94283-97c7-48b3-92bd-dfa9d582ea56} executeQuery: Code: 47. DB::Exception: Unknown expression or function identifier `column_does_not_exists` in scope (SELECT '\n{"a": "Hello", "b": 111}\n{"a": "World", "b": 123}\n' FROM system.one WHERE column_does_not_exists = 4) AS constant_expression. (UNKNOWN_IDENTIFIER) (version 25.3.6.10636.altinitytest (altinity build)) (from [::1]:34308) (comment: 03257_scalar_in_format_table_expression.sql) (query 3, line 20) (in query: -- The scalar subquery is incorrect so it should throw the proper error SELECT * FROM format( JSONEachRow, ( SELECT $$ {"a": "Hello", "b": 111} {"a": "World", "b": 123} $$ WHERE column_does_not_exists = 4 ) );), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.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&&) @ 0x000000001404b3b9 4. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3771: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000001401b849 5. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3980: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000014018e31 6. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:2925: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000001402fcbd 7. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3838: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000014019a9e 8. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5630: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000014013941 9. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000140127f9 10. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000014011fce 11. /build/src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000001406ce8a 12. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:601: DB::QueryAnalyzer::evaluateScalarSubqueryIfNeeded(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000140206e2 13. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:240: DB::QueryAnalyzer::resolveConstantExpression(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000001401fbcf 14. /build/src/Interpreters/evaluateConstantExpression.cpp:115: DB::evaluateConstantExpressionImpl(std::shared_ptr const&, std::shared_ptr const&, bool) @ 0x0000000014c67ee1 15. /build/src/Interpreters/evaluateConstantExpression.cpp:196: DB::evaluateConstantExpression(std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000014c69cb9 16. /build/src/Interpreters/evaluateConstantExpression.cpp:207: DB::evaluateConstantExpressionAsLiteral(std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000014c69e42 17. /build/src/Interpreters/evaluateConstantExpression.cpp:215: DB::evaluateConstantExpressionOrIdentifierAsLiteral(std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000014c69f2a 18. /build/src/TableFunctions/TableFunctionFormat.cpp:81: DB::(anonymous namespace)::TableFunctionFormat::parseArguments(std::shared_ptr const&, std::shared_ptr) @ 0x0000000011858d18 19. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:4834: DB::QueryAnalyzer::resolveTableFunction(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&, bool) @ 0x000000001401cb85 20. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5342: DB::QueryAnalyzer::resolveQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&) @ 0x00000000140452bf 21. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5597: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000140136f0 22. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000140127f9 23. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000014011fce 24. /build/src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000001406ce8a 25. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000014973b42 26. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000001497268d 27. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000014974d24 28. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001492924b 29. /build/src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88641 30. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 31. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 2025.07.28 11:53:03.505433 [ 5879 ] {} TCPHandler: Code: 47. DB::Exception: Unknown expression or function identifier `column_does_not_exists` in scope (SELECT '\n{"a": "Hello", "b": 111}\n{"a": "World", "b": 123}\n' FROM system.one WHERE column_does_not_exists = 4) AS constant_expression. (UNKNOWN_IDENTIFIER), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.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&&) @ 0x000000001404b3b9 4. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3771: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000001401b849 5. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3980: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000014018e31 6. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:2925: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000001402fcbd 7. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3838: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000014019a9e 8. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5630: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000014013941 9. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000140127f9 10. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000014011fce 11. /build/src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000001406ce8a 12. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:601: DB::QueryAnalyzer::evaluateScalarSubqueryIfNeeded(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000140206e2 13. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:240: DB::QueryAnalyzer::resolveConstantExpression(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000001401fbcf 14. /build/src/Interpreters/evaluateConstantExpression.cpp:115: DB::evaluateConstantExpressionImpl(std::shared_ptr const&, std::shared_ptr const&, bool) @ 0x0000000014c67ee1 15. /build/src/Interpreters/evaluateConstantExpression.cpp:196: DB::evaluateConstantExpression(std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000014c69cb9 16. /build/src/Interpreters/evaluateConstantExpression.cpp:207: DB::evaluateConstantExpressionAsLiteral(std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000014c69e42 17. /build/src/Interpreters/evaluateConstantExpression.cpp:215: DB::evaluateConstantExpressionOrIdentifierAsLiteral(std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000014c69f2a 18. /build/src/TableFunctions/TableFunctionFormat.cpp:81: DB::(anonymous namespace)::TableFunctionFormat::parseArguments(std::shared_ptr const&, std::shared_ptr) @ 0x0000000011858d18 19. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:4834: DB::QueryAnalyzer::resolveTableFunction(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&, bool) @ 0x000000001401cb85 20. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5342: DB::QueryAnalyzer::resolveQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&) @ 0x00000000140452bf 21. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5597: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000140136f0 22. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000140127f9 23. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000014011fce 24. /build/src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000001406ce8a 25. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000014973b42 26. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000001497268d 27. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000014974d24 28. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001492924b 29. /build/src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88641 30. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 31. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 2025.07.28 11:53:03.608100 [ 17256 ] {82c424e9-2baf-4008-88fe-509300b8dc48} void DB::TCPHandler::sendData(QueryState &, const Block &): Code: 241. DB::Exception: Query memory limit exceeded: would use 8.00 GiB (attempt to allocate chunk of 8.00 GiB bytes), maximum: 953.67 MiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000000fc1ab36 4. /build/src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000000fc196ef 5. /build/src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000000fc19293 6. /build/src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000000fb80c54 7. /build/src/Common/Allocator.cpp:233: Allocator::realloc(void*, unsigned long, unsigned long, unsigned long) @ 0x000000000fb7f7df 8. /build/src/Common/PODArray.h:152: void DB::PODArrayBase<2ul, 4096ul, Allocator, 63ul, 64ul>::reserve_exact<>(unsigned long) @ 0x000000000e9abfa6 9. /build/src/Columns/ColumnArray.cpp:1141: COW::immutable_ptr DB::ColumnArray::replicateNumber(DB::PODArray, 63ul, 64ul> const&) const @ 0x00000000158f1d60 10. /build/src/Columns/ColumnArray.cpp:1072: DB::ColumnArray::replicate(DB::PODArray, 63ul, 64ul> const&) const @ 0x00000000158e5b2f 11. /build/src/Columns/ColumnConst.cpp:50: DB::ColumnConst::convertToFullColumn() const @ 0x000000001590d996 12. /build/src/Columns/ColumnConst.h:34: DB::ColumnConst::convertToFullColumnIfConst() const @ 0x000000001590eca9 13. /build/src/Formats/NativeWriter.cpp:66: DB::NativeWriter::write(DB::Block const&) @ 0x0000000016973744 14. /build/src/Server/TCPHandler.cpp:2484: DB::TCPHandler::sendData(DB::QueryState&, DB::Block const&) @ 0x00000000168fa2dc 15. /build/src/Server/TCPHandler.cpp:1266: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x00000000168f162c 16. /build/src/Server/TCPHandler.cpp:678: DB::TCPHandler::runImpl() @ 0x00000000168e68e5 17. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 18. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 19. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 20. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 21. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 22. ? @ 0x00007fbc6213eac3 23. ? @ 0x00007fbc621d0850 (version 25.3.6.10636.altinitytest (altinity build)) 2025.07.28 11:53:03.627501 [ 3968 ] {} test_13.rmt2 (7f9b740d-015c-470e-8cc6-8ba33be0dc63): auto DB::StorageReplicatedMergeTree::processQueueEntry(ReplicatedMergeTreeQueue::SelectedEntryPtr)::(anonymous class)::operator()(LogEntryPtr &) const: Code: 86. DB::HTTPException: Received error from remote server http://146b4357c08d:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Ftest%2F01165%2Ftest_13%2Frmt%2Freplicas%2F1&part=20250728_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.6.10636.altinitytest (altinity build)) '. (RECEIVED_ERROR_FROM_REMOTE_IO_SERVER), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.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 const&, int&&, String const&, unsigned long&&, String const&) @ 0x000000000feda8d9 4. /build/src/IO/HTTPCommon.cpp:104: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x000000000feda6e2 5. /build/src/IO/HTTPCommon.cpp:93: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x000000000feda537 6. /build/src/IO/ReadWriteBufferFromHTTP.cpp:277: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x000000001184a4c4 7. /build/src/IO/ReadWriteBufferFromHTTP.cpp:285: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x000000001184a615 8. /build/src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x000000001184ae59 9. /build/src/IO/ReadWriteBufferFromHTTP.cpp:472: void std::__function::__policy_invoker::__call_impl[abi:se190107]>(std::__function::__policy_storage const*) @ 0x000000001184cedd 10. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001184858b 11. /build/src/IO/ReadWriteBufferFromHTTP.cpp:465: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x000000001184bf0b 12. /build/src/IO/ReadBuffer.h:60: DB::ReadBuffer::next() @ 0x000000000a148c7b 13. /build/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) @ 0x0000000011849fb2 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]>&)>&, 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&) @ 0x0000000011841980 15. /build/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) @ 0x000000001621208e 16. /build/src/Storages/StorageReplicatedMergeTree.cpp:5228: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl[abi:se190107] const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000015f9a5fe 17. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000015ed8bfd 18. /build/src/Storages/StorageReplicatedMergeTree.cpp:2514: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x0000000015ec9aab 19. /build/src/Storages/StorageReplicatedMergeTree.cpp:2349: DB::StorageReplicatedMergeTree::executeLogEntry(DB::ReplicatedMergeTreeLogEntry&) @ 0x0000000015eba91b 20. /build/src/Storages/StorageReplicatedMergeTree.cpp:3876: bool std::__function::__policy_invoker&)>::__call_impl[abi:se190107])::$_1, bool (std::shared_ptr&)>>(std::__function::__policy_storage const*, std::shared_ptr&) @ 0x0000000015f9837e 21. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000165d6fc3 22. /build/src/Storages/StorageReplicatedMergeTree.cpp:3872: DB::StorageReplicatedMergeTree::processQueueEntry(std::shared_ptr) @ 0x0000000015efc18a 23. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001624c1b2 24. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000162f9c70 25. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x00000000162fa55a 26. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc6653 27. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000000fccc4c3 28. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc3d92 29. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fcca080 30. ? @ 0x00007fbc6213eac3 31. ? @ 0x00007fbc621d0850 (version 25.3.6.10636.altinitytest (altinity build)) 2025.07.28 11:53:03.643863 [ 17256 ] {82c424e9-2baf-4008-88fe-509300b8dc48} executeQuery: Code: 241. DB::Exception: Query memory limit exceeded: would use 8.00 GiB (attempt to allocate chunk of 8.00 GiB bytes), maximum: 953.67 MiB. (MEMORY_LIMIT_EXCEEDED) (version 25.3.6.10636.altinitytest (altinity build)) (from [::1]:34284) (comment: 01785_parallel_formatting_memory.sh) (query 1, line 1) (in query: SELECT range(65535) FROM system.one ARRAY JOIN range(65536) AS number), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000000fc1ab36 4. /build/src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000000fc196ef 5. /build/src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000000fc19293 6. /build/src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000000fb80c54 7. /build/src/Common/Allocator.cpp:233: Allocator::realloc(void*, unsigned long, unsigned long, unsigned long) @ 0x000000000fb7f7df 8. /build/src/Common/PODArray.h:152: void DB::PODArrayBase<2ul, 4096ul, Allocator, 63ul, 64ul>::reserve_exact<>(unsigned long) @ 0x000000000e9abfa6 9. /build/src/Columns/ColumnArray.cpp:1141: COW::immutable_ptr DB::ColumnArray::replicateNumber(DB::PODArray, 63ul, 64ul> const&) const @ 0x00000000158f1d60 10. /build/src/Columns/ColumnArray.cpp:1072: DB::ColumnArray::replicate(DB::PODArray, 63ul, 64ul> const&) const @ 0x00000000158e5b2f 11. /build/src/Columns/ColumnConst.cpp:50: DB::ColumnConst::convertToFullColumn() const @ 0x000000001590d996 12. /build/src/Columns/ColumnConst.h:34: DB::ColumnConst::convertToFullColumnIfConst() const @ 0x000000001590eca9 13. /build/src/Formats/NativeWriter.cpp:66: DB::NativeWriter::write(DB::Block const&) @ 0x0000000016973744 14. /build/src/Server/TCPHandler.cpp:2484: DB::TCPHandler::sendData(DB::QueryState&, DB::Block const&) @ 0x00000000168fa2dc 15. /build/src/Server/TCPHandler.cpp:1266: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x00000000168f162c 16. /build/src/Server/TCPHandler.cpp:678: DB::TCPHandler::runImpl() @ 0x00000000168e68e5 17. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 18. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 19. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 20. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 21. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 22. ? @ 0x00007fbc6213eac3 23. ? @ 0x00007fbc621d0850 2025.07.28 11:53:03.707199 [ 17256 ] {} TCPHandler: Code: 241. DB::Exception: Query memory limit exceeded: would use 8.00 GiB (attempt to allocate chunk of 8.00 GiB bytes), maximum: 953.67 MiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000000fc1ab36 4. /build/src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000000fc196ef 5. /build/src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000000fc19293 6. /build/src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000000fb80c54 7. /build/src/Common/Allocator.cpp:233: Allocator::realloc(void*, unsigned long, unsigned long, unsigned long) @ 0x000000000fb7f7df 8. /build/src/Common/PODArray.h:152: void DB::PODArrayBase<2ul, 4096ul, Allocator, 63ul, 64ul>::reserve_exact<>(unsigned long) @ 0x000000000e9abfa6 9. /build/src/Columns/ColumnArray.cpp:1141: COW::immutable_ptr DB::ColumnArray::replicateNumber(DB::PODArray, 63ul, 64ul> const&) const @ 0x00000000158f1d60 10. /build/src/Columns/ColumnArray.cpp:1072: DB::ColumnArray::replicate(DB::PODArray, 63ul, 64ul> const&) const @ 0x00000000158e5b2f 11. /build/src/Columns/ColumnConst.cpp:50: DB::ColumnConst::convertToFullColumn() const @ 0x000000001590d996 12. /build/src/Columns/ColumnConst.h:34: DB::ColumnConst::convertToFullColumnIfConst() const @ 0x000000001590eca9 13. /build/src/Formats/NativeWriter.cpp:66: DB::NativeWriter::write(DB::Block const&) @ 0x0000000016973744 14. /build/src/Server/TCPHandler.cpp:2484: DB::TCPHandler::sendData(DB::QueryState&, DB::Block const&) @ 0x00000000168fa2dc 15. /build/src/Server/TCPHandler.cpp:1266: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x00000000168f162c 16. /build/src/Server/TCPHandler.cpp:678: DB::TCPHandler::runImpl() @ 0x00000000168e68e5 17. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 18. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 19. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 20. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 21. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 22. ? @ 0x00007fbc6213eac3 23. ? @ 0x00007fbc621d0850 2025.07.28 11:53:03.833395 [ 5879 ] {031946ab-dc97-4f12-9ab0-5498fc4a9a73} executeQuery: Code: 47. DB::Exception: Unknown expression identifier `where_qualified__fuzz_19` in scope (SELECT where_qualified__fuzz_19 FROM numbers(10000)) AS constant_expression. (UNKNOWN_IDENTIFIER) (version 25.3.6.10636.altinitytest (altinity build)) (from [::1]:34308) (comment: 03257_scalar_in_format_table_expression.sql) (query 5, line 41) (in query: SELECT count() FROM format(TSVRaw, ( SELECT where_qualified__fuzz_19 FROM numbers(10000) ));), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.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&&) @ 0x000000001404b3b9 4. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3771: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000001401b849 5. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3980: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000014018e31 6. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:4304: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000014042fa7 7. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5605: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000014013749 8. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000140127f9 9. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000014011fce 10. /build/src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000001406ce8a 11. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:601: DB::QueryAnalyzer::evaluateScalarSubqueryIfNeeded(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000140206e2 12. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:240: DB::QueryAnalyzer::resolveConstantExpression(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000001401fbcf 13. /build/src/Interpreters/evaluateConstantExpression.cpp:115: DB::evaluateConstantExpressionImpl(std::shared_ptr const&, std::shared_ptr const&, bool) @ 0x0000000014c67ee1 14. /build/src/Interpreters/evaluateConstantExpression.cpp:196: DB::evaluateConstantExpression(std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000014c69cb9 15. /build/src/Interpreters/evaluateConstantExpression.cpp:207: DB::evaluateConstantExpressionAsLiteral(std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000014c69e42 16. /build/src/Interpreters/evaluateConstantExpression.cpp:215: DB::evaluateConstantExpressionOrIdentifierAsLiteral(std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000014c69f2a 17. /build/src/TableFunctions/TableFunctionFormat.cpp:81: DB::(anonymous namespace)::TableFunctionFormat::parseArguments(std::shared_ptr const&, std::shared_ptr) @ 0x0000000011858d18 18. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:4834: DB::QueryAnalyzer::resolveTableFunction(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&, bool) @ 0x000000001401cb85 19. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5342: DB::QueryAnalyzer::resolveQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&) @ 0x00000000140452bf 20. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5597: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000140136f0 21. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000140127f9 22. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000014011fce 23. /build/src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000001406ce8a 24. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000014973b42 25. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000001497268d 26. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000014974d24 27. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001492924b 28. /build/src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88641 29. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 30. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 31. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 2025.07.28 11:53:03.837030 [ 5879 ] {} TCPHandler: Code: 47. DB::Exception: Unknown expression identifier `where_qualified__fuzz_19` in scope (SELECT where_qualified__fuzz_19 FROM numbers(10000)) AS constant_expression. (UNKNOWN_IDENTIFIER), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.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&&) @ 0x000000001404b3b9 4. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3771: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000001401b849 5. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3980: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000014018e31 6. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:4304: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000014042fa7 7. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5605: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000014013749 8. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000140127f9 9. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000014011fce 10. /build/src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000001406ce8a 11. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:601: DB::QueryAnalyzer::evaluateScalarSubqueryIfNeeded(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000140206e2 12. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:240: DB::QueryAnalyzer::resolveConstantExpression(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000001401fbcf 13. /build/src/Interpreters/evaluateConstantExpression.cpp:115: DB::evaluateConstantExpressionImpl(std::shared_ptr const&, std::shared_ptr const&, bool) @ 0x0000000014c67ee1 14. /build/src/Interpreters/evaluateConstantExpression.cpp:196: DB::evaluateConstantExpression(std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000014c69cb9 15. /build/src/Interpreters/evaluateConstantExpression.cpp:207: DB::evaluateConstantExpressionAsLiteral(std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000014c69e42 16. /build/src/Interpreters/evaluateConstantExpression.cpp:215: DB::evaluateConstantExpressionOrIdentifierAsLiteral(std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000014c69f2a 17. /build/src/TableFunctions/TableFunctionFormat.cpp:81: DB::(anonymous namespace)::TableFunctionFormat::parseArguments(std::shared_ptr const&, std::shared_ptr) @ 0x0000000011858d18 18. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:4834: DB::QueryAnalyzer::resolveTableFunction(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&, bool) @ 0x000000001401cb85 19. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5342: DB::QueryAnalyzer::resolveQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&) @ 0x00000000140452bf 20. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5597: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000140136f0 21. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000140127f9 22. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000014011fce 23. /build/src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000001406ce8a 24. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000014973b42 25. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000001497268d 26. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000014974d24 27. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001492924b 28. /build/src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88641 29. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 30. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 31. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 2025.07.28 11:53:04.101532 [ 5879 ] {9b7bebe1-a487-4369-9add-f072568b8b7f} executeQuery: Code: 47. DB::Exception: Unknown expression identifier `where_qualified__fuzz_19` in scope SELECT where_qualified__fuzz_19 FROM numbers(10000). (UNKNOWN_IDENTIFIER) (version 25.3.6.10636.altinitytest (altinity build)) (from [::1]:34308) (comment: 03257_scalar_in_format_table_expression.sql) (query 6, line 47) (in query: SELECT count() FROM format(TSVRaw, ( SELECT where_qualified__fuzz_19 FROM numbers(10000) UNION ALL SELECT where_qualified__fuzz_35 FROM numbers(10000) ));), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.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&&) @ 0x000000001404b3b9 4. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3771: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000001401b849 5. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3980: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000014018e31 6. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:4304: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000014042fa7 7. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5605: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000014013749 8. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5864: DB::QueryAnalyzer::resolveUnion(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000014016727 9. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:186: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000140127d9 10. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000014011fce 11. /build/src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000001406ce8a 12. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:601: DB::QueryAnalyzer::evaluateScalarSubqueryIfNeeded(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000140206e2 13. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:240: DB::QueryAnalyzer::resolveConstantExpression(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000001401fbcf 14. /build/src/Interpreters/evaluateConstantExpression.cpp:115: DB::evaluateConstantExpressionImpl(std::shared_ptr const&, std::shared_ptr const&, bool) @ 0x0000000014c67ee1 15. /build/src/Interpreters/evaluateConstantExpression.cpp:196: DB::evaluateConstantExpression(std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000014c69cb9 16. /build/src/Interpreters/evaluateConstantExpression.cpp:207: DB::evaluateConstantExpressionAsLiteral(std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000014c69e42 17. /build/src/Interpreters/evaluateConstantExpression.cpp:215: DB::evaluateConstantExpressionOrIdentifierAsLiteral(std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000014c69f2a 18. /build/src/TableFunctions/TableFunctionFormat.cpp:81: DB::(anonymous namespace)::TableFunctionFormat::parseArguments(std::shared_ptr const&, std::shared_ptr) @ 0x0000000011858d18 19. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:4834: DB::QueryAnalyzer::resolveTableFunction(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&, bool) @ 0x000000001401cb85 20. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5342: DB::QueryAnalyzer::resolveQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&) @ 0x00000000140452bf 21. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5597: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000140136f0 22. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000140127f9 23. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000014011fce 24. /build/src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000001406ce8a 25. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000014973b42 26. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000001497268d 27. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000014974d24 28. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001492924b 29. /build/src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88641 30. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 31. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 2025.07.28 11:53:04.106287 [ 5879 ] {} TCPHandler: Code: 47. DB::Exception: Unknown expression identifier `where_qualified__fuzz_19` in scope SELECT where_qualified__fuzz_19 FROM numbers(10000). (UNKNOWN_IDENTIFIER), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.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&&) @ 0x000000001404b3b9 4. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3771: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000001401b849 5. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3980: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000014018e31 6. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:4304: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000014042fa7 7. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5605: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000014013749 8. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5864: DB::QueryAnalyzer::resolveUnion(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000014016727 9. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:186: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000140127d9 10. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000014011fce 11. /build/src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000001406ce8a 12. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:601: DB::QueryAnalyzer::evaluateScalarSubqueryIfNeeded(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000140206e2 13. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:240: DB::QueryAnalyzer::resolveConstantExpression(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000001401fbcf 14. /build/src/Interpreters/evaluateConstantExpression.cpp:115: DB::evaluateConstantExpressionImpl(std::shared_ptr const&, std::shared_ptr const&, bool) @ 0x0000000014c67ee1 15. /build/src/Interpreters/evaluateConstantExpression.cpp:196: DB::evaluateConstantExpression(std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000014c69cb9 16. /build/src/Interpreters/evaluateConstantExpression.cpp:207: DB::evaluateConstantExpressionAsLiteral(std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000014c69e42 17. /build/src/Interpreters/evaluateConstantExpression.cpp:215: DB::evaluateConstantExpressionOrIdentifierAsLiteral(std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000014c69f2a 18. /build/src/TableFunctions/TableFunctionFormat.cpp:81: DB::(anonymous namespace)::TableFunctionFormat::parseArguments(std::shared_ptr const&, std::shared_ptr) @ 0x0000000011858d18 19. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:4834: DB::QueryAnalyzer::resolveTableFunction(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&, bool) @ 0x000000001401cb85 20. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5342: DB::QueryAnalyzer::resolveQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&) @ 0x00000000140452bf 21. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5597: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000140136f0 22. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000140127f9 23. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000014011fce 24. /build/src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000001406ce8a 25. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000014973b42 26. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000001497268d 27. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000014974d24 28. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001492924b 29. /build/src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88641 30. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 31. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 2025.07.28 11:53:04.128391 [ 3974 ] {} test_13.rmt2 (7f9b740d-015c-470e-8cc6-8ba33be0dc63): auto DB::StorageReplicatedMergeTree::processQueueEntry(ReplicatedMergeTreeQueue::SelectedEntryPtr)::(anonymous class)::operator()(LogEntryPtr &) const: Code: 86. DB::HTTPException: Received error from remote server http://146b4357c08d:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Ftest%2F01165%2Ftest_13%2Frmt%2Freplicas%2F1&part=20250728_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.6.10636.altinitytest (altinity build)) '. (RECEIVED_ERROR_FROM_REMOTE_IO_SERVER), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.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 const&, int&&, String const&, unsigned long&&, String const&) @ 0x000000000feda8d9 4. /build/src/IO/HTTPCommon.cpp:104: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x000000000feda6e2 5. /build/src/IO/HTTPCommon.cpp:93: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x000000000feda537 6. /build/src/IO/ReadWriteBufferFromHTTP.cpp:277: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x000000001184a4c4 7. /build/src/IO/ReadWriteBufferFromHTTP.cpp:285: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x000000001184a615 8. /build/src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x000000001184ae59 9. /build/src/IO/ReadWriteBufferFromHTTP.cpp:472: void std::__function::__policy_invoker::__call_impl[abi:se190107]>(std::__function::__policy_storage const*) @ 0x000000001184cedd 10. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001184858b 11. /build/src/IO/ReadWriteBufferFromHTTP.cpp:465: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x000000001184bf0b 12. /build/src/IO/ReadBuffer.h:60: DB::ReadBuffer::next() @ 0x000000000a148c7b 13. /build/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) @ 0x0000000011849fb2 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]>&)>&, 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&) @ 0x0000000011841980 15. /build/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) @ 0x000000001621208e 16. /build/src/Storages/StorageReplicatedMergeTree.cpp:5228: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl[abi:se190107] const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000015f9a5fe 17. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000015ed8bfd 18. /build/src/Storages/StorageReplicatedMergeTree.cpp:2514: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x0000000015ec9aab 19. /build/src/Storages/StorageReplicatedMergeTree.cpp:2349: DB::StorageReplicatedMergeTree::executeLogEntry(DB::ReplicatedMergeTreeLogEntry&) @ 0x0000000015eba91b 20. /build/src/Storages/StorageReplicatedMergeTree.cpp:3876: bool std::__function::__policy_invoker&)>::__call_impl[abi:se190107])::$_1, bool (std::shared_ptr&)>>(std::__function::__policy_storage const*, std::shared_ptr&) @ 0x0000000015f9837e 21. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000165d6fc3 22. /build/src/Storages/StorageReplicatedMergeTree.cpp:3872: DB::StorageReplicatedMergeTree::processQueueEntry(std::shared_ptr) @ 0x0000000015efc18a 23. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001624c1b2 24. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000162f9c70 25. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x00000000162fa55a 26. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc6653 27. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000000fccc4c3 28. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc3d92 29. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fcca080 30. ? @ 0x00007fbc6213eac3 31. ? @ 0x00007fbc621d0850 (version 25.3.6.10636.altinitytest (altinity build)) 2025.07.28 11:53:04.255933 [ 5879 ] {0539e3e4-7ec0-44ff-b776-e88fd886b9d8} executeQuery: Code: 47. DB::Exception: Unknown expression identifier `where_qualified__fuzz_19` in scope (SELECT where_qualified__fuzz_19 FROM numbers(10000)) AS s. (UNKNOWN_IDENTIFIER) (version 25.3.6.10636.altinitytest (altinity build)) (from [::1]:34308) (comment: 03257_scalar_in_format_table_expression.sql) (query 7, line 56) (in query: WITH ( SELECT where_qualified__fuzz_19 FROM numbers(10000) ) as s SELECT count() FROM format(TSVRaw, s);), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.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&&) @ 0x000000001404b3b9 4. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3771: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000001401b849 5. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3980: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000014018e31 6. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:4304: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000014042fa7 7. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5605: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000014013749 8. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3870: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x00000000140199de 9. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:1247: DB::QueryAnalyzer::tryResolveIdentifierFromAliases(DB::IdentifierLookup const&, DB::IdentifierResolveScope&, DB::IdentifierResolveContext) @ 0x0000000014028604 10. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:1493: DB::QueryAnalyzer::tryResolveIdentifier(DB::IdentifierLookup const&, DB::IdentifierResolveScope&, DB::IdentifierResolveContext) @ 0x000000001402950d 11. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:4772: DB::QueryAnalyzer::resolveTableFunction(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&, bool) @ 0x000000001401c59d 12. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5342: DB::QueryAnalyzer::resolveQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&) @ 0x00000000140452bf 13. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5597: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000140136f0 14. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000140127f9 15. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000014011fce 16. /build/src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000001406ce8a 17. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000014973b42 18. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000001497268d 19. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000014974d24 20. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001492924b 21. /build/src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88641 22. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 23. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 24. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 25. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 26. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 27. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 28. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 29. ? @ 0x00007fbc6213eac3 30. ? @ 0x00007fbc621d0850 2025.07.28 11:53:04.268880 [ 5879 ] {} TCPHandler: Code: 47. DB::Exception: Unknown expression identifier `where_qualified__fuzz_19` in scope (SELECT where_qualified__fuzz_19 FROM numbers(10000)) AS s. (UNKNOWN_IDENTIFIER), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.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&&) @ 0x000000001404b3b9 4. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3771: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000001401b849 5. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3980: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000014018e31 6. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:4304: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000014042fa7 7. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5605: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000014013749 8. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3870: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x00000000140199de 9. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:1247: DB::QueryAnalyzer::tryResolveIdentifierFromAliases(DB::IdentifierLookup const&, DB::IdentifierResolveScope&, DB::IdentifierResolveContext) @ 0x0000000014028604 10. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:1493: DB::QueryAnalyzer::tryResolveIdentifier(DB::IdentifierLookup const&, DB::IdentifierResolveScope&, DB::IdentifierResolveContext) @ 0x000000001402950d 11. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:4772: DB::QueryAnalyzer::resolveTableFunction(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&, bool) @ 0x000000001401c59d 12. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5342: DB::QueryAnalyzer::resolveQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&) @ 0x00000000140452bf 13. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5597: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000140136f0 14. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000140127f9 15. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000014011fce 16. /build/src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000001406ce8a 17. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000014973b42 18. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000001497268d 19. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000014974d24 20. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001492924b 21. /build/src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88641 22. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 23. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 24. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 25. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 26. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 27. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 28. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 29. ? @ 0x00007fbc6213eac3 30. ? @ 0x00007fbc621d0850 2025.07.28 11:53:04.528033 [ 5879 ] {1cd29112-35e2-49ec-a855-dbde0171bc17} executeQuery: Code: 47. DB::Exception: Unknown expression or function identifier `TSVRaw` in scope (SELECT CAST(arrayStringConcat(groupArray(format(TSVRaw, (SELECT CAST(arrayStringConcat(1 GLOBAL IN (SELECT 1 FROM system.one WHERE 1 GLOBAL IN (SELECT toUInt128(1) FROM system.one GROUP BY GROUPING SETS ((1)) WITH ROLLUP) GROUP BY 1 WITH CUBE), groupArray('some long string')), 'LowCardinality(String)') FROM numbers(10000))), toLowCardinality('some long string')) RESPECT NULLS, '\n'), 'LowCardinality(String)') FROM numbers(10000)) AS constant_expression. (UNKNOWN_IDENTIFIER) (version 25.3.6.10636.altinitytest (altinity build)) (from [::1]:34308) (comment: 03257_scalar_in_format_table_expression.sql) (query 8, line 62) (in query: -- https://github.com/ClickHouse/ClickHouse/issues/70675 SELECT count() FROM format(TSVRaw, ( SELECT CAST(arrayStringConcat(groupArray(format(TSVRaw, ( SELECT CAST(arrayStringConcat(1 GLOBAL IN ( SELECT 1 WHERE 1 GLOBAL IN ( SELECT toUInt128(1) GROUP BY GROUPING SETS ((1)) WITH ROLLUP ) GROUP BY 1 WITH CUBE ), groupArray('some long string')), 'LowCardinality(String)') FROM numbers(10000) )), toLowCardinality('some long string')) RESPECT NULLS, '\n'), 'LowCardinality(String)') FROM numbers(10000) )) FORMAT TSVRaw;), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.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&&) @ 0x000000001404b3b9 4. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3771: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000001401b849 5. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3980: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000014018e31 6. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:2925: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000001402fcbd 7. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3838: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000014019a9e 8. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3980: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000014018e31 9. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:2925: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000001402fcbd 10. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3838: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000014019a9e 11. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3980: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000014018e31 12. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:2925: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000001402fcbd 13. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3838: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000014019a9e 14. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3980: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000014018e31 15. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:2925: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000001402fcbd 16. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3838: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000014019a9e 17. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3980: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000014018e31 18. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:4304: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000014042fa7 19. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5605: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000014013749 20. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000140127f9 21. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000014011fce 22. /build/src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000001406ce8a 23. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:601: DB::QueryAnalyzer::evaluateScalarSubqueryIfNeeded(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000140206e2 24. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:240: DB::QueryAnalyzer::resolveConstantExpression(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000001401fbcf 25. /build/src/Interpreters/evaluateConstantExpression.cpp:115: DB::evaluateConstantExpressionImpl(std::shared_ptr const&, std::shared_ptr const&, bool) @ 0x0000000014c67ee1 26. /build/src/Interpreters/evaluateConstantExpression.cpp:196: DB::evaluateConstantExpression(std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000014c69cb9 27. /build/src/Interpreters/evaluateConstantExpression.cpp:207: DB::evaluateConstantExpressionAsLiteral(std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000014c69e42 28. /build/src/Interpreters/evaluateConstantExpression.cpp:215: DB::evaluateConstantExpressionOrIdentifierAsLiteral(std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000014c69f2a 29. /build/src/TableFunctions/TableFunctionFormat.cpp:81: DB::(anonymous namespace)::TableFunctionFormat::parseArguments(std::shared_ptr const&, std::shared_ptr) @ 0x0000000011858d18 30. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:4834: DB::QueryAnalyzer::resolveTableFunction(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&, bool) @ 0x000000001401cb85 31. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5342: DB::QueryAnalyzer::resolveQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&) @ 0x00000000140452bf 2025.07.28 11:53:04.539556 [ 5879 ] {} TCPHandler: Code: 47. DB::Exception: Unknown expression or function identifier `TSVRaw` in scope (SELECT CAST(arrayStringConcat(groupArray(format(TSVRaw, (SELECT CAST(arrayStringConcat(1 GLOBAL IN (SELECT 1 FROM system.one WHERE 1 GLOBAL IN (SELECT toUInt128(1) FROM system.one GROUP BY GROUPING SETS ((1)) WITH ROLLUP) GROUP BY 1 WITH CUBE), groupArray('some long string')), 'LowCardinality(String)') FROM numbers(10000))), toLowCardinality('some long string')) RESPECT NULLS, '\n'), 'LowCardinality(String)') FROM numbers(10000)) AS constant_expression. (UNKNOWN_IDENTIFIER), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.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&&) @ 0x000000001404b3b9 4. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3771: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000001401b849 5. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3980: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000014018e31 6. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:2925: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000001402fcbd 7. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3838: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000014019a9e 8. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3980: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000014018e31 9. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:2925: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000001402fcbd 10. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3838: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000014019a9e 11. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3980: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000014018e31 12. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:2925: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000001402fcbd 13. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3838: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000014019a9e 14. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3980: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000014018e31 15. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:2925: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000001402fcbd 16. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3838: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000014019a9e 17. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3980: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000014018e31 18. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:4304: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000014042fa7 19. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5605: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000014013749 20. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000140127f9 21. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000014011fce 22. /build/src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000001406ce8a 23. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:601: DB::QueryAnalyzer::evaluateScalarSubqueryIfNeeded(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000140206e2 24. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:240: DB::QueryAnalyzer::resolveConstantExpression(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000001401fbcf 25. /build/src/Interpreters/evaluateConstantExpression.cpp:115: DB::evaluateConstantExpressionImpl(std::shared_ptr const&, std::shared_ptr const&, bool) @ 0x0000000014c67ee1 26. /build/src/Interpreters/evaluateConstantExpression.cpp:196: DB::evaluateConstantExpression(std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000014c69cb9 27. /build/src/Interpreters/evaluateConstantExpression.cpp:207: DB::evaluateConstantExpressionAsLiteral(std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000014c69e42 28. /build/src/Interpreters/evaluateConstantExpression.cpp:215: DB::evaluateConstantExpressionOrIdentifierAsLiteral(std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000014c69f2a 29. /build/src/TableFunctions/TableFunctionFormat.cpp:81: DB::(anonymous namespace)::TableFunctionFormat::parseArguments(std::shared_ptr const&, std::shared_ptr) @ 0x0000000011858d18 30. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:4834: DB::QueryAnalyzer::resolveTableFunction(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&, bool) @ 0x000000001401cb85 31. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5342: DB::QueryAnalyzer::resolveQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&) @ 0x00000000140452bf 2025.07.28 11:53:04.709466 [ 5879 ] {7d6904d5-5455-4bd0-9508-99be2b1be919} executeQuery: Code: 47. DB::Exception: Unknown expression identifier `DEFAULT` in scope (SELECT DEFAULT FROM system.one) AS constant_expression. (UNKNOWN_IDENTIFIER) (version 25.3.6.10636.altinitytest (altinity build)) (from [::1]:34308) (comment: 03257_scalar_in_format_table_expression.sql) (query 9, line 83) (in query: -- Same but for table function numbers SELECT 1 FROM numbers((SELECT DEFAULT));), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.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&&) @ 0x000000001404b3b9 4. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3771: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000001401b849 5. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3980: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000014018e31 6. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:4304: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000014042fa7 7. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5605: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000014013749 8. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000140127f9 9. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000014011fce 10. /build/src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000001406ce8a 11. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:601: DB::QueryAnalyzer::evaluateScalarSubqueryIfNeeded(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000140206e2 12. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:240: DB::QueryAnalyzer::resolveConstantExpression(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000001401fbcf 13. /build/src/Interpreters/evaluateConstantExpression.cpp:115: DB::evaluateConstantExpressionImpl(std::shared_ptr const&, std::shared_ptr const&, bool) @ 0x0000000014c67ee1 14. /build/src/Interpreters/evaluateConstantExpression.cpp:196: DB::evaluateConstantExpression(std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000014c69cb9 15. /build/src/TableFunctions/TableFunctionNumbers.cpp:102: DB::(anonymous namespace)::TableFunctionNumbers::evaluateArgument(std::shared_ptr, std::shared_ptr&) const @ 0x00000000118106b3 16. /build/src/TableFunctions/TableFunctionNumbers.cpp:80: DB::(anonymous namespace)::TableFunctionNumbers::executeImpl(std::shared_ptr const&, std::shared_ptr, String const&, DB::ColumnsDescription, bool) const @ 0x0000000011810145 17. /build/src/TableFunctions/ITableFunction.cpp:36: DB::ITableFunction::execute(std::shared_ptr const&, std::shared_ptr, String const&, DB::ColumnsDescription, bool, bool) const @ 0x00000000131e9fc3 18. /build/src/Interpreters/Context.cpp:2501: DB::Context::executeTableFunction(std::shared_ptr const&, std::shared_ptr const&) @ 0x00000000144345b2 19. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:4975: DB::QueryAnalyzer::resolveTableFunction(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&, bool) @ 0x000000001401e9f9 20. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5342: DB::QueryAnalyzer::resolveQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&) @ 0x00000000140452bf 21. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5597: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000140136f0 22. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000140127f9 23. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000014011fce 24. /build/src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000001406ce8a 25. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000014973b42 26. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000001497268d 27. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000014974d24 28. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001492924b 29. /build/src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88641 30. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 31. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 2025.07.28 11:53:04.714988 [ 5879 ] {} TCPHandler: Code: 47. DB::Exception: Unknown expression identifier `DEFAULT` in scope (SELECT DEFAULT FROM system.one) AS constant_expression. (UNKNOWN_IDENTIFIER), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.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&&) @ 0x000000001404b3b9 4. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3771: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000001401b849 5. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3980: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000014018e31 6. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:4304: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000014042fa7 7. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5605: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000014013749 8. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000140127f9 9. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000014011fce 10. /build/src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000001406ce8a 11. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:601: DB::QueryAnalyzer::evaluateScalarSubqueryIfNeeded(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000140206e2 12. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:240: DB::QueryAnalyzer::resolveConstantExpression(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000001401fbcf 13. /build/src/Interpreters/evaluateConstantExpression.cpp:115: DB::evaluateConstantExpressionImpl(std::shared_ptr const&, std::shared_ptr const&, bool) @ 0x0000000014c67ee1 14. /build/src/Interpreters/evaluateConstantExpression.cpp:196: DB::evaluateConstantExpression(std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000014c69cb9 15. /build/src/TableFunctions/TableFunctionNumbers.cpp:102: DB::(anonymous namespace)::TableFunctionNumbers::evaluateArgument(std::shared_ptr, std::shared_ptr&) const @ 0x00000000118106b3 16. /build/src/TableFunctions/TableFunctionNumbers.cpp:80: DB::(anonymous namespace)::TableFunctionNumbers::executeImpl(std::shared_ptr const&, std::shared_ptr, String const&, DB::ColumnsDescription, bool) const @ 0x0000000011810145 17. /build/src/TableFunctions/ITableFunction.cpp:36: DB::ITableFunction::execute(std::shared_ptr const&, std::shared_ptr, String const&, DB::ColumnsDescription, bool, bool) const @ 0x00000000131e9fc3 18. /build/src/Interpreters/Context.cpp:2501: DB::Context::executeTableFunction(std::shared_ptr const&, std::shared_ptr const&) @ 0x00000000144345b2 19. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:4975: DB::QueryAnalyzer::resolveTableFunction(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&, bool) @ 0x000000001401e9f9 20. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5342: DB::QueryAnalyzer::resolveQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&) @ 0x00000000140452bf 21. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5597: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000140136f0 22. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000140127f9 23. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000014011fce 24. /build/src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000001406ce8a 25. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000014973b42 26. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000001497268d 27. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000014974d24 28. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001492924b 29. /build/src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88641 30. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 31. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 2025.07.28 11:53:04.972755 [ 22706 ] {} ExternalDictionariesLoader: Could not load external dictionary 'cc8b1a52-da70-449c-9c23-8d623c5fcc44', next update is scheduled at 2025-07-28 11:53:09: Code: 396. DB::Exception: Limit for result exceeded, max bytes: 1.00 B, current bytes: 36.00 B. (TOO_MANY_ROWS_OR_BYTES), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, char const*&, ReadableSize&&, ReadableSize&&) @ 0x0000000013bd4eeb 4. /build/src/QueryPipeline/SizeLimits.cpp:43: DB::SizeLimits::check(unsigned long, unsigned long, char const*, int, int) const @ 0x0000000013bd48a1 5. /build/src/Processors/Transforms/LimitsCheckingTransform.cpp:45: DB::LimitsCheckingTransform::transform(DB::Chunk&) @ 0x0000000016c1d2fb 6. /build/src/Processors/ISimpleTransform.h:33: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000011a9a453 7. /build/src/Processors/ISimpleTransform.cpp:89: DB::ISimpleTransform::work() @ 0x000000001699fca0 8. /build/src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x00000000169bd00f 9. /build/src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x00000000169b2105 10. /build/src/Processors/Executors/PipelineExecutor.cpp:170: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x00000000169b16a7 11. /build/src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x00000000169c081c 12. /build/src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x00000000169c0978 13. /build/src/Dictionaries/FlatDictionary.cpp:502: DB::FlatDictionary::loadData() @ 0x0000000011b424cb 14. /build/src/Dictionaries/FlatDictionary.cpp:46: DB::FlatDictionary::FlatDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, DB::FlatDictionary::Configuration, std::shared_ptr) @ 0x0000000011b42111 15. /build/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:se190107]> (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) @ 0x0000000011b5d3e2 16. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000012d8a61d 17. /build/src/Interpreters/ExternalDictionariesLoader.cpp:47: DB::ExternalDictionariesLoader::createObject(String const&, Poco::Util::AbstractConfiguration const&, String const&, String const&) const @ 0x00000000148a6f44 18. /build/src/Interpreters/ExternalLoader.cpp:1522: DB::ExternalLoader::LoadingDispatcher::loadSingleObject(String const&, DB::ExternalLoader::ObjectConfig const&, std::shared_ptr) @ 0x00000000148b2ee8 19. /build/src/Interpreters/ExternalLoader.cpp:998: DB::ExternalLoader::LoadingDispatcher::doLoading(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr) @ 0x00000000148b197d 20. /build/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()() @ 0x00000000148b5991 21. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc3d92 22. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fcca080 23. ? @ 0x00007fbc6213eac3 24. ? @ 0x00007fbc621d0850 (version 25.3.6.10636.altinitytest (altinity build)) 2025.07.28 11:53:04.981373 [ 3965 ] {} test_13.rmt2 (7f9b740d-015c-470e-8cc6-8ba33be0dc63): auto DB::StorageReplicatedMergeTree::processQueueEntry(ReplicatedMergeTreeQueue::SelectedEntryPtr)::(anonymous class)::operator()(LogEntryPtr &) const: Code: 86. DB::HTTPException: Received error from remote server http://146b4357c08d:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Ftest%2F01165%2Ftest_13%2Frmt%2Freplicas%2F1&part=20250728_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.6.10636.altinitytest (altinity build)) '. (RECEIVED_ERROR_FROM_REMOTE_IO_SERVER), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.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 const&, int&&, String const&, unsigned long&&, String const&) @ 0x000000000feda8d9 4. /build/src/IO/HTTPCommon.cpp:104: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x000000000feda6e2 5. /build/src/IO/HTTPCommon.cpp:93: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x000000000feda537 6. /build/src/IO/ReadWriteBufferFromHTTP.cpp:277: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x000000001184a4c4 7. /build/src/IO/ReadWriteBufferFromHTTP.cpp:285: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x000000001184a615 8. /build/src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x000000001184ae59 9. /build/src/IO/ReadWriteBufferFromHTTP.cpp:472: void std::__function::__policy_invoker::__call_impl[abi:se190107]>(std::__function::__policy_storage const*) @ 0x000000001184cedd 10. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001184858b 11. /build/src/IO/ReadWriteBufferFromHTTP.cpp:465: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x000000001184bf0b 12. /build/src/IO/ReadBuffer.h:60: DB::ReadBuffer::next() @ 0x000000000a148c7b 13. /build/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) @ 0x0000000011849fb2 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]>&)>&, 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&) @ 0x0000000011841980 15. /build/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) @ 0x000000001621208e 16. /build/src/Storages/StorageReplicatedMergeTree.cpp:5228: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl[abi:se190107] const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000015f9a5fe 17. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000015ed8bfd 18. /build/src/Storages/StorageReplicatedMergeTree.cpp:2514: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x0000000015ec9aab 19. /build/src/Storages/StorageReplicatedMergeTree.cpp:2349: DB::StorageReplicatedMergeTree::executeLogEntry(DB::ReplicatedMergeTreeLogEntry&) @ 0x0000000015eba91b 20. /build/src/Storages/StorageReplicatedMergeTree.cpp:3876: bool std::__function::__policy_invoker&)>::__call_impl[abi:se190107])::$_1, bool (std::shared_ptr&)>>(std::__function::__policy_storage const*, std::shared_ptr&) @ 0x0000000015f9837e 21. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000165d6fc3 22. /build/src/Storages/StorageReplicatedMergeTree.cpp:3872: DB::StorageReplicatedMergeTree::processQueueEntry(std::shared_ptr) @ 0x0000000015efc18a 23. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001624c1b2 24. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000162f9c70 25. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x00000000162fa55a 26. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc6653 27. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000000fccc4c3 28. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc3d92 29. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fcca080 30. ? @ 0x00007fbc6213eac3 31. ? @ 0x00007fbc621d0850 (version 25.3.6.10636.altinitytest (altinity build)) 2025.07.28 11:53:05.435369 [ 17321 ] {09fc4282-72b7-47c1-b455-b7e740e8f189} 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.6.10636.altinitytest (altinity build)) (from [::1]:34424) (comment: 02487_create_index_normalize_functions.sql) (query 1, line 2) (in query: CREATE TABLE rmt (`n` int, `ts` DateTime64(8, 'UTC')) ENGINE = ReplicatedMergeTree('/test/02487/{database}/rmt', '1') ORDER BY n SETTINGS index_granularity = 46036, min_bytes_for_wide_part = 545352495, 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 = 164792606, compact_parts_max_granules_to_buffer = 58, compact_parts_merge_max_bytes_to_prefetch_part = 30684683, merge_max_block_size = 17259, old_parts_lifetime = 480., 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 = 1780458491, index_granularity_bytes = 21186735, 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 = 57827, primary_key_compress_block_size = 72404, 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. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000000a074fcb 4. /build/src/Databases/DatabaseReplicated.cpp:959: DB::DatabaseReplicated::checkTableEngine(DB::ASTCreateQuery const&, DB::ASTStorage&, std::shared_ptr) const @ 0x0000000013d9cf56 5. /build/src/Databases/DatabaseReplicated.cpp:1083: DB::DatabaseReplicated::checkQueryValid(std::shared_ptr const&, std::shared_ptr) const @ 0x0000000013d9ebb5 6. /build/src/Databases/DatabaseReplicated.cpp:1130: DB::DatabaseReplicated::tryEnqueueReplicatedDDL(std::shared_ptr const&, std::shared_ptr, DB::QueryFlags) @ 0x0000000013d9f10b 7. /build/src/Interpreters/InterpreterCreateQuery.cpp:1723: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000148f96f8 8. /build/src/Interpreters/InterpreterCreateQuery.cpp:2352: DB::InterpreterCreateQuery::execute() @ 0x0000000014905a41 9. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88dc9 10. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 11. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 12. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 13. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 14. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 16. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 17. ? @ 0x00007fbc6213eac3 18. ? @ 0x00007fbc621d0850 2025.07.28 11:53:05.448124 [ 17321 ] {} 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. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000000a074fcb 4. /build/src/Databases/DatabaseReplicated.cpp:959: DB::DatabaseReplicated::checkTableEngine(DB::ASTCreateQuery const&, DB::ASTStorage&, std::shared_ptr) const @ 0x0000000013d9cf56 5. /build/src/Databases/DatabaseReplicated.cpp:1083: DB::DatabaseReplicated::checkQueryValid(std::shared_ptr const&, std::shared_ptr) const @ 0x0000000013d9ebb5 6. /build/src/Databases/DatabaseReplicated.cpp:1130: DB::DatabaseReplicated::tryEnqueueReplicatedDDL(std::shared_ptr const&, std::shared_ptr, DB::QueryFlags) @ 0x0000000013d9f10b 7. /build/src/Interpreters/InterpreterCreateQuery.cpp:1723: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000148f96f8 8. /build/src/Interpreters/InterpreterCreateQuery.cpp:2352: DB::InterpreterCreateQuery::execute() @ 0x0000000014905a41 9. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88dc9 10. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 11. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 12. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 13. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 14. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 16. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 17. ? @ 0x00007fbc6213eac3 18. ? @ 0x00007fbc621d0850 2025.07.28 11:53:05.782414 [ 3961 ] {} test_13.rmt2 (7f9b740d-015c-470e-8cc6-8ba33be0dc63): auto DB::StorageReplicatedMergeTree::processQueueEntry(ReplicatedMergeTreeQueue::SelectedEntryPtr)::(anonymous class)::operator()(LogEntryPtr &) const: Code: 86. DB::HTTPException: Received error from remote server http://146b4357c08d:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Ftest%2F01165%2Ftest_13%2Frmt%2Freplicas%2F1&part=20250728_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.6.10636.altinitytest (altinity build)) '. (RECEIVED_ERROR_FROM_REMOTE_IO_SERVER), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.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 const&, int&&, String const&, unsigned long&&, String const&) @ 0x000000000feda8d9 4. /build/src/IO/HTTPCommon.cpp:104: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x000000000feda6e2 5. /build/src/IO/HTTPCommon.cpp:93: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x000000000feda537 6. /build/src/IO/ReadWriteBufferFromHTTP.cpp:277: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x000000001184a4c4 7. /build/src/IO/ReadWriteBufferFromHTTP.cpp:285: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x000000001184a615 8. /build/src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x000000001184ae59 9. /build/src/IO/ReadWriteBufferFromHTTP.cpp:472: void std::__function::__policy_invoker::__call_impl[abi:se190107]>(std::__function::__policy_storage const*) @ 0x000000001184cedd 10. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001184858b 11. /build/src/IO/ReadWriteBufferFromHTTP.cpp:465: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x000000001184bf0b 12. /build/src/IO/ReadBuffer.h:60: DB::ReadBuffer::next() @ 0x000000000a148c7b 13. /build/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) @ 0x0000000011849fb2 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]>&)>&, 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&) @ 0x0000000011841980 15. /build/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) @ 0x000000001621208e 16. /build/src/Storages/StorageReplicatedMergeTree.cpp:5228: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl[abi:se190107] const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000015f9a5fe 17. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000015ed8bfd 18. /build/src/Storages/StorageReplicatedMergeTree.cpp:2514: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x0000000015ec9aab 19. /build/src/Storages/StorageReplicatedMergeTree.cpp:2349: DB::StorageReplicatedMergeTree::executeLogEntry(DB::ReplicatedMergeTreeLogEntry&) @ 0x0000000015eba91b 20. /build/src/Storages/StorageReplicatedMergeTree.cpp:3876: bool std::__function::__policy_invoker&)>::__call_impl[abi:se190107])::$_1, bool (std::shared_ptr&)>>(std::__function::__policy_storage const*, std::shared_ptr&) @ 0x0000000015f9837e 21. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000165d6fc3 22. /build/src/Storages/StorageReplicatedMergeTree.cpp:3872: DB::StorageReplicatedMergeTree::processQueueEntry(std::shared_ptr) @ 0x0000000015efc18a 23. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001624c1b2 24. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000162f9c70 25. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x00000000162fa55a 26. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc6653 27. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000000fccc4c3 28. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc3d92 29. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fcca080 30. ? @ 0x00007fbc6213eac3 31. ? @ 0x00007fbc621d0850 (version 25.3.6.10636.altinitytest (altinity build)) 2025.07.28 11:53:06.332843 [ 17256 ] {431ecad4-c9df-4395-99a4-80337771cf37} void DB::TCPHandler::sendData(QueryState &, const Block &): Code: 241. DB::Exception: Query memory limit exceeded: would use 8.00 GiB (attempt to allocate chunk of 8.00 GiB bytes), maximum: 953.67 MiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000000fc1ab36 4. /build/src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000000fc196ef 5. /build/src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000000fc19293 6. /build/src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000000fb80c54 7. /build/src/Common/Allocator.cpp:233: Allocator::realloc(void*, unsigned long, unsigned long, unsigned long) @ 0x000000000fb7f7df 8. /build/src/Common/PODArray.h:152: void DB::PODArrayBase<2ul, 4096ul, Allocator, 63ul, 64ul>::reserve_exact<>(unsigned long) @ 0x000000000e9abfa6 9. /build/src/Columns/ColumnArray.cpp:1141: COW::immutable_ptr DB::ColumnArray::replicateNumber(DB::PODArray, 63ul, 64ul> const&) const @ 0x00000000158f1d60 10. /build/src/Columns/ColumnArray.cpp:1072: DB::ColumnArray::replicate(DB::PODArray, 63ul, 64ul> const&) const @ 0x00000000158e5b2f 11. /build/src/Columns/ColumnConst.cpp:50: DB::ColumnConst::convertToFullColumn() const @ 0x000000001590d996 12. /build/src/Columns/ColumnConst.h:34: DB::ColumnConst::convertToFullColumnIfConst() const @ 0x000000001590eca9 13. /build/src/Formats/NativeWriter.cpp:66: DB::NativeWriter::write(DB::Block const&) @ 0x0000000016973744 14. /build/src/Server/TCPHandler.cpp:2484: DB::TCPHandler::sendData(DB::QueryState&, DB::Block const&) @ 0x00000000168fa2dc 15. /build/src/Server/TCPHandler.cpp:1266: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x00000000168f162c 16. /build/src/Server/TCPHandler.cpp:678: DB::TCPHandler::runImpl() @ 0x00000000168e68e5 17. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 18. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 19. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 20. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 21. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 22. ? @ 0x00007fbc6213eac3 23. ? @ 0x00007fbc621d0850 (version 25.3.6.10636.altinitytest (altinity build)) 2025.07.28 11:53:06.360038 [ 17256 ] {431ecad4-c9df-4395-99a4-80337771cf37} executeQuery: Code: 241. DB::Exception: Query memory limit exceeded: would use 8.00 GiB (attempt to allocate chunk of 8.00 GiB bytes), maximum: 953.67 MiB. (MEMORY_LIMIT_EXCEEDED) (version 25.3.6.10636.altinitytest (altinity build)) (from [::1]:34378) (comment: 01785_parallel_formatting_memory.sh) (query 1, line 1) (in query: SELECT range(65535) FROM system.one ARRAY JOIN range(65536) AS number), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000000fc1ab36 4. /build/src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000000fc196ef 5. /build/src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000000fc19293 6. /build/src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000000fb80c54 7. /build/src/Common/Allocator.cpp:233: Allocator::realloc(void*, unsigned long, unsigned long, unsigned long) @ 0x000000000fb7f7df 8. /build/src/Common/PODArray.h:152: void DB::PODArrayBase<2ul, 4096ul, Allocator, 63ul, 64ul>::reserve_exact<>(unsigned long) @ 0x000000000e9abfa6 9. /build/src/Columns/ColumnArray.cpp:1141: COW::immutable_ptr DB::ColumnArray::replicateNumber(DB::PODArray, 63ul, 64ul> const&) const @ 0x00000000158f1d60 10. /build/src/Columns/ColumnArray.cpp:1072: DB::ColumnArray::replicate(DB::PODArray, 63ul, 64ul> const&) const @ 0x00000000158e5b2f 11. /build/src/Columns/ColumnConst.cpp:50: DB::ColumnConst::convertToFullColumn() const @ 0x000000001590d996 12. /build/src/Columns/ColumnConst.h:34: DB::ColumnConst::convertToFullColumnIfConst() const @ 0x000000001590eca9 13. /build/src/Formats/NativeWriter.cpp:66: DB::NativeWriter::write(DB::Block const&) @ 0x0000000016973744 14. /build/src/Server/TCPHandler.cpp:2484: DB::TCPHandler::sendData(DB::QueryState&, DB::Block const&) @ 0x00000000168fa2dc 15. /build/src/Server/TCPHandler.cpp:1266: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x00000000168f162c 16. /build/src/Server/TCPHandler.cpp:678: DB::TCPHandler::runImpl() @ 0x00000000168e68e5 17. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 18. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 19. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 20. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 21. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 22. ? @ 0x00007fbc6213eac3 23. ? @ 0x00007fbc621d0850 2025.07.28 11:53:06.406364 [ 17256 ] {} TCPHandler: Code: 241. DB::Exception: Query memory limit exceeded: would use 8.00 GiB (attempt to allocate chunk of 8.00 GiB bytes), maximum: 953.67 MiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000000fc1ab36 4. /build/src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000000fc196ef 5. /build/src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000000fc19293 6. /build/src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000000fb80c54 7. /build/src/Common/Allocator.cpp:233: Allocator::realloc(void*, unsigned long, unsigned long, unsigned long) @ 0x000000000fb7f7df 8. /build/src/Common/PODArray.h:152: void DB::PODArrayBase<2ul, 4096ul, Allocator, 63ul, 64ul>::reserve_exact<>(unsigned long) @ 0x000000000e9abfa6 9. /build/src/Columns/ColumnArray.cpp:1141: COW::immutable_ptr DB::ColumnArray::replicateNumber(DB::PODArray, 63ul, 64ul> const&) const @ 0x00000000158f1d60 10. /build/src/Columns/ColumnArray.cpp:1072: DB::ColumnArray::replicate(DB::PODArray, 63ul, 64ul> const&) const @ 0x00000000158e5b2f 11. /build/src/Columns/ColumnConst.cpp:50: DB::ColumnConst::convertToFullColumn() const @ 0x000000001590d996 12. /build/src/Columns/ColumnConst.h:34: DB::ColumnConst::convertToFullColumnIfConst() const @ 0x000000001590eca9 13. /build/src/Formats/NativeWriter.cpp:66: DB::NativeWriter::write(DB::Block const&) @ 0x0000000016973744 14. /build/src/Server/TCPHandler.cpp:2484: DB::TCPHandler::sendData(DB::QueryState&, DB::Block const&) @ 0x00000000168fa2dc 15. /build/src/Server/TCPHandler.cpp:1266: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x00000000168f162c 16. /build/src/Server/TCPHandler.cpp:678: DB::TCPHandler::runImpl() @ 0x00000000168e68e5 17. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 18. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 19. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 20. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 21. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 22. ? @ 0x00007fbc6213eac3 23. ? @ 0x00007fbc621d0850 2025.07.28 11:53:06.428068 [ 3972 ] {} test_13.rmt2 (7f9b740d-015c-470e-8cc6-8ba33be0dc63): auto DB::StorageReplicatedMergeTree::processQueueEntry(ReplicatedMergeTreeQueue::SelectedEntryPtr)::(anonymous class)::operator()(LogEntryPtr &) const: Code: 86. DB::HTTPException: Received error from remote server http://146b4357c08d:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Ftest%2F01165%2Ftest_13%2Frmt%2Freplicas%2F1&part=20250728_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.6.10636.altinitytest (altinity build)) '. (RECEIVED_ERROR_FROM_REMOTE_IO_SERVER), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.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 const&, int&&, String const&, unsigned long&&, String const&) @ 0x000000000feda8d9 4. /build/src/IO/HTTPCommon.cpp:104: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x000000000feda6e2 5. /build/src/IO/HTTPCommon.cpp:93: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x000000000feda537 6. /build/src/IO/ReadWriteBufferFromHTTP.cpp:277: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x000000001184a4c4 7. /build/src/IO/ReadWriteBufferFromHTTP.cpp:285: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x000000001184a615 8. /build/src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x000000001184ae59 9. /build/src/IO/ReadWriteBufferFromHTTP.cpp:472: void std::__function::__policy_invoker::__call_impl[abi:se190107]>(std::__function::__policy_storage const*) @ 0x000000001184cedd 10. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001184858b 11. /build/src/IO/ReadWriteBufferFromHTTP.cpp:465: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x000000001184bf0b 12. /build/src/IO/ReadBuffer.h:60: DB::ReadBuffer::next() @ 0x000000000a148c7b 13. /build/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) @ 0x0000000011849fb2 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]>&)>&, 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&) @ 0x0000000011841980 15. /build/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) @ 0x000000001621208e 16. /build/src/Storages/StorageReplicatedMergeTree.cpp:5228: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl[abi:se190107] const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000015f9a5fe 17. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000015ed8bfd 18. /build/src/Storages/StorageReplicatedMergeTree.cpp:2514: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x0000000015ec9aab 19. /build/src/Storages/StorageReplicatedMergeTree.cpp:2349: DB::StorageReplicatedMergeTree::executeLogEntry(DB::ReplicatedMergeTreeLogEntry&) @ 0x0000000015eba91b 20. /build/src/Storages/StorageReplicatedMergeTree.cpp:3876: bool std::__function::__policy_invoker&)>::__call_impl[abi:se190107])::$_1, bool (std::shared_ptr&)>>(std::__function::__policy_storage const*, std::shared_ptr&) @ 0x0000000015f9837e 21. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000165d6fc3 22. /build/src/Storages/StorageReplicatedMergeTree.cpp:3872: DB::StorageReplicatedMergeTree::processQueueEntry(std::shared_ptr) @ 0x0000000015efc18a 23. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001624c1b2 24. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000162f9c70 25. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x00000000162fa55a 26. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc6653 27. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000000fccc4c3 28. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc3d92 29. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fcca080 30. ? @ 0x00007fbc6213eac3 31. ? @ 0x00007fbc621d0850 (version 25.3.6.10636.altinitytest (altinity build)) 2025.07.28 11:53:06.715862 [ 17210 ] {206f0ac0-2b23-46fb-8eed-05f4a626435c} executeQuery: Code: 43. DB::Exception: Illegal types Decimal(6, 4) and Decimal(6, 4) of arguments for aggregate function covarPop. (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.6.10636.altinitytest (altinity build)) (from [::1]:47476) (comment: 00700_decimal_empty_aggregates.sql) (query 58, line 80) (in query: SELECT covarPop(a, a), covarPop(b, b), covarPop(c, c) FROM decimal;), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String const&) @ 0x000000001011aceb 4. /build/src/AggregateFunctions/AggregateFunctionStatisticsSimple.h:266: std::shared_ptr DB::createAggregateFunctionStatisticsBinary(String const&, std::vector, std::allocator>> const&, DB::Array const&, DB::Settings const*) @ 0x0000000010c906fa 5. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000131e00dd 6. /build/src/AggregateFunctions/AggregateFunctionFactory.cpp:130: DB::AggregateFunctionFactory::get(String const&, DB::NullsAction, std::vector, std::allocator>> const&, DB::Array const&, DB::AggregateFunctionProperties&) const @ 0x00000000131df0ca 7. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3368: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000014032fed 8. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3838: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000014019a9e 9. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3980: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000014018e31 10. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:4304: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000014042fa7 11. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5605: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000014013749 12. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000140127f9 13. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000014011fce 14. /build/src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000001406ce8a 15. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000014973b42 16. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000001497268d 17. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000014974d24 18. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001492924b 19. /build/src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88641 20. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 21. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 22. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 23. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 24. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 25. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 26. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 27. ? @ 0x00007fbc6213eac3 28. ? @ 0x00007fbc621d0850 2025.07.28 11:53:06.719420 [ 17210 ] {} TCPHandler: Code: 43. DB::Exception: Illegal types Decimal(6, 4) and Decimal(6, 4) of arguments for aggregate function covarPop. (ILLEGAL_TYPE_OF_ARGUMENT), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String const&) @ 0x000000001011aceb 4. /build/src/AggregateFunctions/AggregateFunctionStatisticsSimple.h:266: std::shared_ptr DB::createAggregateFunctionStatisticsBinary(String const&, std::vector, std::allocator>> const&, DB::Array const&, DB::Settings const*) @ 0x0000000010c906fa 5. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000131e00dd 6. /build/src/AggregateFunctions/AggregateFunctionFactory.cpp:130: DB::AggregateFunctionFactory::get(String const&, DB::NullsAction, std::vector, std::allocator>> const&, DB::Array const&, DB::AggregateFunctionProperties&) const @ 0x00000000131df0ca 7. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3368: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000014032fed 8. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3838: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000014019a9e 9. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3980: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000014018e31 10. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:4304: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000014042fa7 11. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5605: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000014013749 12. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000140127f9 13. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000014011fce 14. /build/src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000001406ce8a 15. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000014973b42 16. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000001497268d 17. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000014974d24 18. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001492924b 19. /build/src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88641 20. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 21. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 22. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 23. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 24. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 25. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 26. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 27. ? @ 0x00007fbc6213eac3 28. ? @ 0x00007fbc621d0850 2025.07.28 11:53:06.946737 [ 17210 ] {fa1ca8e1-d50b-4cad-929f-e26b237aaba5} executeQuery: Code: 43. DB::Exception: Illegal types Decimal(6, 4) and Decimal(6, 4) of arguments for aggregate function covarSamp. (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.6.10636.altinitytest (altinity build)) (from [::1]:47476) (comment: 00700_decimal_empty_aggregates.sql) (query 59, line 81) (in query: SELECT covarSamp(a, a), covarSamp(b, b), covarSamp(c, c) FROM decimal;), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String const&) @ 0x000000001011aceb 4. /build/src/AggregateFunctions/AggregateFunctionStatisticsSimple.h:266: std::shared_ptr DB::createAggregateFunctionStatisticsBinary(String const&, std::vector, std::allocator>> const&, DB::Array const&, DB::Settings const*) @ 0x0000000010c9045a 5. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000131e00dd 6. /build/src/AggregateFunctions/AggregateFunctionFactory.cpp:130: DB::AggregateFunctionFactory::get(String const&, DB::NullsAction, std::vector, std::allocator>> const&, DB::Array const&, DB::AggregateFunctionProperties&) const @ 0x00000000131df0ca 7. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3368: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000014032fed 8. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3838: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000014019a9e 9. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3980: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000014018e31 10. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:4304: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000014042fa7 11. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5605: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000014013749 12. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000140127f9 13. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000014011fce 14. /build/src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000001406ce8a 15. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000014973b42 16. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000001497268d 17. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000014974d24 18. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001492924b 19. /build/src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88641 20. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 21. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 22. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 23. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 24. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 25. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 26. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 27. ? @ 0x00007fbc6213eac3 28. ? @ 0x00007fbc621d0850 2025.07.28 11:53:06.953457 [ 17210 ] {} TCPHandler: Code: 43. DB::Exception: Illegal types Decimal(6, 4) and Decimal(6, 4) of arguments for aggregate function covarSamp. (ILLEGAL_TYPE_OF_ARGUMENT), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String const&) @ 0x000000001011aceb 4. /build/src/AggregateFunctions/AggregateFunctionStatisticsSimple.h:266: std::shared_ptr DB::createAggregateFunctionStatisticsBinary(String const&, std::vector, std::allocator>> const&, DB::Array const&, DB::Settings const*) @ 0x0000000010c9045a 5. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000131e00dd 6. /build/src/AggregateFunctions/AggregateFunctionFactory.cpp:130: DB::AggregateFunctionFactory::get(String const&, DB::NullsAction, std::vector, std::allocator>> const&, DB::Array const&, DB::AggregateFunctionProperties&) const @ 0x00000000131df0ca 7. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3368: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000014032fed 8. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3838: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000014019a9e 9. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3980: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000014018e31 10. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:4304: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000014042fa7 11. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5605: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000014013749 12. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000140127f9 13. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000014011fce 14. /build/src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000001406ce8a 15. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000014973b42 16. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000001497268d 17. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000014974d24 18. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001492924b 19. /build/src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88641 20. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 21. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 22. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 23. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 24. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 25. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 26. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 27. ? @ 0x00007fbc6213eac3 28. ? @ 0x00007fbc621d0850 2025.07.28 11:53:07.113105 [ 17210 ] {1a8ebe40-02c9-40a9-8db4-c57d57a0100f} executeQuery: Code: 43. DB::Exception: Illegal types Decimal(6, 4) and Decimal(6, 4) of arguments for aggregate function corr. (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.6.10636.altinitytest (altinity build)) (from [::1]:47476) (comment: 00700_decimal_empty_aggregates.sql) (query 60, line 82) (in query: SELECT corr(a, a), corr(b, b), corr(c, c) FROM decimal;), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String const&) @ 0x000000001011aceb 4. /build/src/AggregateFunctions/AggregateFunctionStatisticsSimple.h:266: std::shared_ptr DB::createAggregateFunctionStatisticsBinary(String const&, std::vector, std::allocator>> const&, DB::Array const&, DB::Settings const*) @ 0x0000000010d49fea 5. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000131e00dd 6. /build/src/AggregateFunctions/AggregateFunctionFactory.cpp:130: DB::AggregateFunctionFactory::get(String const&, DB::NullsAction, std::vector, std::allocator>> const&, DB::Array const&, DB::AggregateFunctionProperties&) const @ 0x00000000131df0ca 7. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3368: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000014032fed 8. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3838: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000014019a9e 9. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3980: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000014018e31 10. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:4304: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000014042fa7 11. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5605: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000014013749 12. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000140127f9 13. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000014011fce 14. /build/src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000001406ce8a 15. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000014973b42 16. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000001497268d 17. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000014974d24 18. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001492924b 19. /build/src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88641 20. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 21. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 22. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 23. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 24. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 25. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 26. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 27. ? @ 0x00007fbc6213eac3 28. ? @ 0x00007fbc621d0850 2025.07.28 11:53:07.117711 [ 17210 ] {} TCPHandler: Code: 43. DB::Exception: Illegal types Decimal(6, 4) and Decimal(6, 4) of arguments for aggregate function corr. (ILLEGAL_TYPE_OF_ARGUMENT), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String const&) @ 0x000000001011aceb 4. /build/src/AggregateFunctions/AggregateFunctionStatisticsSimple.h:266: std::shared_ptr DB::createAggregateFunctionStatisticsBinary(String const&, std::vector, std::allocator>> const&, DB::Array const&, DB::Settings const*) @ 0x0000000010d49fea 5. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000131e00dd 6. /build/src/AggregateFunctions/AggregateFunctionFactory.cpp:130: DB::AggregateFunctionFactory::get(String const&, DB::NullsAction, std::vector, std::allocator>> const&, DB::Array const&, DB::AggregateFunctionProperties&) const @ 0x00000000131df0ca 7. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3368: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000014032fed 8. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3838: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000014019a9e 9. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3980: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000014018e31 10. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:4304: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000014042fa7 11. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5605: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000014013749 12. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000140127f9 13. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000014011fce 14. /build/src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000001406ce8a 15. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000014973b42 16. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000001497268d 17. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000014974d24 18. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001492924b 19. /build/src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88641 20. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 21. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 22. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 23. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 24. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 25. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 26. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 27. ? @ 0x00007fbc6213eac3 28. ? @ 0x00007fbc621d0850 2025.07.28 11:53:07.528361 [ 3976 ] {} test_13.rmt2 (7f9b740d-015c-470e-8cc6-8ba33be0dc63): auto DB::StorageReplicatedMergeTree::processQueueEntry(ReplicatedMergeTreeQueue::SelectedEntryPtr)::(anonymous class)::operator()(LogEntryPtr &) const: Code: 86. DB::HTTPException: Received error from remote server http://146b4357c08d:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Ftest%2F01165%2Ftest_13%2Frmt%2Freplicas%2F1&part=20250728_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.6.10636.altinitytest (altinity build)) '. (RECEIVED_ERROR_FROM_REMOTE_IO_SERVER), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.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 const&, int&&, String const&, unsigned long&&, String const&) @ 0x000000000feda8d9 4. /build/src/IO/HTTPCommon.cpp:104: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x000000000feda6e2 5. /build/src/IO/HTTPCommon.cpp:93: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x000000000feda537 6. /build/src/IO/ReadWriteBufferFromHTTP.cpp:277: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x000000001184a4c4 7. /build/src/IO/ReadWriteBufferFromHTTP.cpp:285: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x000000001184a615 8. /build/src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x000000001184ae59 9. /build/src/IO/ReadWriteBufferFromHTTP.cpp:472: void std::__function::__policy_invoker::__call_impl[abi:se190107]>(std::__function::__policy_storage const*) @ 0x000000001184cedd 10. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001184858b 11. /build/src/IO/ReadWriteBufferFromHTTP.cpp:465: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x000000001184bf0b 12. /build/src/IO/ReadBuffer.h:60: DB::ReadBuffer::next() @ 0x000000000a148c7b 13. /build/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) @ 0x0000000011849fb2 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]>&)>&, 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&) @ 0x0000000011841980 15. /build/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) @ 0x000000001621208e 16. /build/src/Storages/StorageReplicatedMergeTree.cpp:5228: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl[abi:se190107] const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000015f9a5fe 17. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000015ed8bfd 18. /build/src/Storages/StorageReplicatedMergeTree.cpp:2514: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x0000000015ec9aab 19. /build/src/Storages/StorageReplicatedMergeTree.cpp:2349: DB::StorageReplicatedMergeTree::executeLogEntry(DB::ReplicatedMergeTreeLogEntry&) @ 0x0000000015eba91b 20. /build/src/Storages/StorageReplicatedMergeTree.cpp:3876: bool std::__function::__policy_invoker&)>::__call_impl[abi:se190107])::$_1, bool (std::shared_ptr&)>>(std::__function::__policy_storage const*, std::shared_ptr&) @ 0x0000000015f9837e 21. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000165d6fc3 22. /build/src/Storages/StorageReplicatedMergeTree.cpp:3872: DB::StorageReplicatedMergeTree::processQueueEntry(std::shared_ptr) @ 0x0000000015efc18a 23. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001624c1b2 24. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000162f9c70 25. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x00000000162fa55a 26. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc6653 27. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000000fccc4c3 28. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc3d92 29. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fcca080 30. ? @ 0x00007fbc6213eac3 31. ? @ 0x00007fbc621d0850 (version 25.3.6.10636.altinitytest (altinity build)) 2025.07.28 11:53:07.678863 [ 17203 ] {cdd05c9c-1cf5-4cf7-979e-512d36d40a6f} executeQuery: Code: 128. DB::Exception: Too large array size (maximum: 1073741824): While executing BinaryRowInputFormat. (TOO_LARGE_ARRAY_SIZE) (version 25.3.6.10636.altinitytest (altinity build)) (from [::1]:34568) (comment: 02682_quantiles_too_large_size.sql) (query 1, line 1) (in query: -- This query throw high-level exception instead of low-level "too large size passed to allocator": SELECT * FROM format(RowBinary, 'ik2 String, Sum AggregateFunction(sum, UInt16), A$g AggregateFunction(quantiles(0.4, 0.9), UInt64), GroupArray AggregateFunction(groupArray, String)', '295TMi44400000005942762421546108502 ö z *  ParalcelParsingInputFormat   te Date, I ! STRING  d Tuple(UInt8) vvvvvvvvvvvvvvvvvvvvvvvvvvvvvvvvvvvvvvvvvvvvvvvvvvvvvvvvvvvvTabSeparatedWithNamesAndTypes d Date, a S)ring, x UInt32, y UInt64, z Float32 29TabSeparatevvvvvvvdRawWithNames a UInt32 26TabSeparatedR,éb UInt32 26TabSeparatedRawWithNthNames vvvvv 1 key U7878 ');), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type>, unsigned long const&) @ 0x000000000a951dcb 4. /build/src/AggregateFunctions/ReservoirSampler.h:216: ReservoirSampler>::read(DB::ReadBuffer&) @ 0x000000001036d1cb 5. /build/src/DataTypes/Serializations/SerializationAggregateFunction.cpp:47: DB::SerializationAggregateFunction::deserializeBinary(DB::IColumn&, DB::ReadBuffer&, DB::FormatSettings const&) const @ 0x0000000013c806c0 6. /build/src/Processors/Formats/Impl/BinaryRowInputFormat.cpp:136: DB::BinaryRowInputFormat::readRow(std::vector::mutable_ptr, std::allocator::mutable_ptr>>&, DB::RowReadExtension&) @ 0x0000000016a3bd94 7. /build/src/Processors/Formats/IRowInputFormat.cpp:143: DB::IRowInputFormat::read() @ 0x0000000016a1fc72 8. /build/src/Processors/Formats/IInputFormat.cpp:19: DB::IInputFormat::generate() @ 0x00000000169c5536 9. /build/src/Processors/ISource.cpp:139: DB::ISource::tryGenerate() @ 0x00000000169a24fa 10. /build/src/Processors/ISource.cpp:108: DB::ISource::work() @ 0x00000000169a21e7 11. /build/src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x00000000169bd00f 12. /build/src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x00000000169b2105 13. /build/src/Processors/Executors/PipelineExecutor.cpp:170: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x00000000169b16a7 14. /build/src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x00000000169c081c 15. /build/src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x00000000169c0978 16. /build/src/TableFunctions/TableFunctionFormat.cpp:125: DB::(anonymous namespace)::TableFunctionFormat::executeImpl(std::shared_ptr const&, std::shared_ptr, String const&, DB::ColumnsDescription, bool) const @ 0x0000000011859cbf 17. /build/src/TableFunctions/ITableFunction.cpp:36: DB::ITableFunction::execute(std::shared_ptr const&, std::shared_ptr, String const&, DB::ColumnsDescription, bool, bool) const @ 0x00000000131e9fc3 18. /build/src/Interpreters/Context.cpp:2501: DB::Context::executeTableFunction(std::shared_ptr const&, std::shared_ptr const&) @ 0x00000000144345b2 19. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:4975: DB::QueryAnalyzer::resolveTableFunction(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&, bool) @ 0x000000001401e9f9 20. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5342: DB::QueryAnalyzer::resolveQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&) @ 0x00000000140452bf 21. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5597: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000140136f0 22. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000140127f9 23. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000014011fce 24. /build/src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000001406ce8a 25. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000014973b42 26. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000001497268d 27. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000014974d24 28. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001492924b 29. /build/src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88641 30. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 31. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 2025.07.28 11:53:07.683676 [ 17203 ] {} TCPHandler: Code: 128. DB::Exception: Too large array size (maximum: 1073741824): While executing BinaryRowInputFormat. (TOO_LARGE_ARRAY_SIZE), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type>, unsigned long const&) @ 0x000000000a951dcb 4. /build/src/AggregateFunctions/ReservoirSampler.h:216: ReservoirSampler>::read(DB::ReadBuffer&) @ 0x000000001036d1cb 5. /build/src/DataTypes/Serializations/SerializationAggregateFunction.cpp:47: DB::SerializationAggregateFunction::deserializeBinary(DB::IColumn&, DB::ReadBuffer&, DB::FormatSettings const&) const @ 0x0000000013c806c0 6. /build/src/Processors/Formats/Impl/BinaryRowInputFormat.cpp:136: DB::BinaryRowInputFormat::readRow(std::vector::mutable_ptr, std::allocator::mutable_ptr>>&, DB::RowReadExtension&) @ 0x0000000016a3bd94 7. /build/src/Processors/Formats/IRowInputFormat.cpp:143: DB::IRowInputFormat::read() @ 0x0000000016a1fc72 8. /build/src/Processors/Formats/IInputFormat.cpp:19: DB::IInputFormat::generate() @ 0x00000000169c5536 9. /build/src/Processors/ISource.cpp:139: DB::ISource::tryGenerate() @ 0x00000000169a24fa 10. /build/src/Processors/ISource.cpp:108: DB::ISource::work() @ 0x00000000169a21e7 11. /build/src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x00000000169bd00f 12. /build/src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x00000000169b2105 13. /build/src/Processors/Executors/PipelineExecutor.cpp:170: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x00000000169b16a7 14. /build/src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x00000000169c081c 15. /build/src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x00000000169c0978 16. /build/src/TableFunctions/TableFunctionFormat.cpp:125: DB::(anonymous namespace)::TableFunctionFormat::executeImpl(std::shared_ptr const&, std::shared_ptr, String const&, DB::ColumnsDescription, bool) const @ 0x0000000011859cbf 17. /build/src/TableFunctions/ITableFunction.cpp:36: DB::ITableFunction::execute(std::shared_ptr const&, std::shared_ptr, String const&, DB::ColumnsDescription, bool, bool) const @ 0x00000000131e9fc3 18. /build/src/Interpreters/Context.cpp:2501: DB::Context::executeTableFunction(std::shared_ptr const&, std::shared_ptr const&) @ 0x00000000144345b2 19. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:4975: DB::QueryAnalyzer::resolveTableFunction(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&, bool) @ 0x000000001401e9f9 20. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5342: DB::QueryAnalyzer::resolveQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&) @ 0x00000000140452bf 21. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5597: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000140136f0 22. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000140127f9 23. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000014011fce 24. /build/src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000001406ce8a 25. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000014973b42 26. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000001497268d 27. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000014974d24 28. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001492924b 29. /build/src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88641 30. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 31. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 2025.07.28 11:53:08.348891 [ 17270 ] {} 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. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Access/AccessControl.cpp:646: DB::AccessControl::authenticate(DB::Credentials const&, Poco::Net::IPAddress const&, DB::ClientInfo const&) const @ 0x0000000013727552 4. /build/src/Interpreters/Session.cpp:371: DB::Session::authenticate(DB::Credentials const&, Poco::Net::SocketAddress const&, std::vector> const&) @ 0x0000000014a6dd4d 5. /build/src/Interpreters/Session.cpp:350: DB::Session::authenticate(String const&, String const&, Poco::Net::SocketAddress const&, std::vector> const&) @ 0x0000000014a6d7b0 6. /build/src/Server/TCPHandler.cpp:1798: DB::TCPHandler::receiveHello() @ 0x00000000168ed801 7. /build/src/Server/TCPHandler.cpp:339: DB::TCPHandler::runImpl() @ 0x00000000168e59e6 8. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 9. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 10. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 11. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 12. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 13. ? @ 0x00007fbc6213eac3 14. ? @ 0x00007fbc621d0850 (version 25.3.6.10636.altinitytest (altinity build)) 2025.07.28 11:53:08.349365 [ 17270 ] {} 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. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Access/AccessControl.cpp:646: DB::AccessControl::authenticate(DB::Credentials const&, Poco::Net::IPAddress const&, DB::ClientInfo const&) const @ 0x0000000013727552 4. /build/src/Interpreters/Session.cpp:371: DB::Session::authenticate(DB::Credentials const&, Poco::Net::SocketAddress const&, std::vector> const&) @ 0x0000000014a6dd4d 5. /build/src/Interpreters/Session.cpp:350: DB::Session::authenticate(String const&, String const&, Poco::Net::SocketAddress const&, std::vector> const&) @ 0x0000000014a6d7b0 6. /build/src/Server/TCPHandler.cpp:1798: DB::TCPHandler::receiveHello() @ 0x00000000168ed801 7. /build/src/Server/TCPHandler.cpp:339: DB::TCPHandler::runImpl() @ 0x00000000168e59e6 8. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 9. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 10. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 11. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 12. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 13. ? @ 0x00007fbc6213eac3 14. ? @ 0x00007fbc621d0850 (version 25.3.6.10636.altinitytest (altinity build)) 2025.07.28 11:53:08.387660 [ 12807 ] {7943357b-2cbd-4151-a473-419c5407b635} 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. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Access/AccessControl.cpp:646: DB::AccessControl::authenticate(DB::Credentials const&, Poco::Net::IPAddress const&, DB::ClientInfo const&) const @ 0x0000000013727552 4. /build/src/Interpreters/Session.cpp:371: DB::Session::authenticate(DB::Credentials const&, Poco::Net::SocketAddress const&, std::vector> const&) @ 0x0000000014a6dd4d 5. /build/src/Interpreters/Session.cpp:350: DB::Session::authenticate(String const&, String const&, Poco::Net::SocketAddress const&, std::vector> const&) @ 0x0000000014a6d7b0 6. /build/src/Server/TCPHandler.cpp:1798: DB::TCPHandler::receiveHello() @ 0x00000000168ed801 7. /build/src/Server/TCPHandler.cpp:339: DB::TCPHandler::runImpl() @ 0x00000000168e59e6 8. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 9. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 10. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 11. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 12. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 13. ? @ 0x00007fbc6213eac3 14. ? @ 0x00007fbc621d0850 . (AUTHENTICATION_FAILED) (version 25.3.6.10636.altinitytest (altinity build)) (from [::1]:34600) (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. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:111: DB::readException(DB::ReadBuffer&, String const&, bool) @ 0x000000000fc6e157 3. /build/src/Client/Connection.cpp:1445: DB::Connection::receiveException() const @ 0x00000000167d4127 4. /build/src/Client/Connection.cpp:577: DB::Connection::receiveHello(Poco::Timespan const&) @ 0x00000000167d27a3 5. /build/src/Client/Connection.cpp:235: DB::Connection::connect(DB::ConnectionTimeouts const&) @ 0x00000000167d0891 6. /build/src/Client/Connection.cpp:635: DB::Connection::getServerRevision(DB::ConnectionTimeouts const&) @ 0x00000000167d46b5 7. /build/src/Client/ConnectionEstablisher.cpp:56: DB::ConnectionEstablisher::run(PoolWithFailoverBase::TryResult&, String&, bool) @ 0x00000000167e5d4b 8. /build/src/Client/ConnectionEstablisher.cpp:154: DB::ConnectionEstablisherAsync::Task::run(std::function, std::function) @ 0x00000000167e7751 9. /build/src/Common/AsyncTaskExecutor.cpp:89: DB::AsyncTaskExecutor::Routine::operator()(std::function) @ 0x0000000013bd1892 10. /build/src/Common/Fiber.h:76: boost::context::detail::fiber_record>::run(void*) @ 0x0000000013bd16fa 11. /build/contrib/boost/boost/context/fiber_fcontext.hpp:97: void boost::context::detail::fiber_entry>>(boost::context::detail::transfer_t) @ 0x0000000013bd1621 2025.07.28 11:53:08.404717 [ 12807 ] {} 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. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Access/AccessControl.cpp:646: DB::AccessControl::authenticate(DB::Credentials const&, Poco::Net::IPAddress const&, DB::ClientInfo const&) const @ 0x0000000013727552 4. /build/src/Interpreters/Session.cpp:371: DB::Session::authenticate(DB::Credentials const&, Poco::Net::SocketAddress const&, std::vector> const&) @ 0x0000000014a6dd4d 5. /build/src/Interpreters/Session.cpp:350: DB::Session::authenticate(String const&, String const&, Poco::Net::SocketAddress const&, std::vector> const&) @ 0x0000000014a6d7b0 6. /build/src/Server/TCPHandler.cpp:1798: DB::TCPHandler::receiveHello() @ 0x00000000168ed801 7. /build/src/Server/TCPHandler.cpp:339: DB::TCPHandler::runImpl() @ 0x00000000168e59e6 8. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 9. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 10. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 11. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 12. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 13. ? @ 0x00007fbc6213eac3 14. ? @ 0x00007fbc621d0850 . (AUTHENTICATION_FAILED), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:111: DB::readException(DB::ReadBuffer&, String const&, bool) @ 0x000000000fc6e157 3. /build/src/Client/Connection.cpp:1445: DB::Connection::receiveException() const @ 0x00000000167d4127 4. /build/src/Client/Connection.cpp:577: DB::Connection::receiveHello(Poco::Timespan const&) @ 0x00000000167d27a3 5. /build/src/Client/Connection.cpp:235: DB::Connection::connect(DB::ConnectionTimeouts const&) @ 0x00000000167d0891 6. /build/src/Client/Connection.cpp:635: DB::Connection::getServerRevision(DB::ConnectionTimeouts const&) @ 0x00000000167d46b5 7. /build/src/Client/ConnectionEstablisher.cpp:56: DB::ConnectionEstablisher::run(PoolWithFailoverBase::TryResult&, String&, bool) @ 0x00000000167e5d4b 8. /build/src/Client/ConnectionEstablisher.cpp:154: DB::ConnectionEstablisherAsync::Task::run(std::function, std::function) @ 0x00000000167e7751 9. /build/src/Common/AsyncTaskExecutor.cpp:89: DB::AsyncTaskExecutor::Routine::operator()(std::function) @ 0x0000000013bd1892 10. /build/src/Common/Fiber.h:76: boost::context::detail::fiber_record>::run(void*) @ 0x0000000013bd16fa 11. /build/contrib/boost/boost/context/fiber_fcontext.hpp:97: void boost::context::detail::fiber_entry>>(boost::context::detail::transfer_t) @ 0x0000000013bd1621 2025.07.28 11:53:08.471252 [ 3977 ] {} test_13.rmt2 (7f9b740d-015c-470e-8cc6-8ba33be0dc63): auto DB::StorageReplicatedMergeTree::processQueueEntry(ReplicatedMergeTreeQueue::SelectedEntryPtr)::(anonymous class)::operator()(LogEntryPtr &) const: Code: 86. DB::HTTPException: Received error from remote server http://146b4357c08d:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Ftest%2F01165%2Ftest_13%2Frmt%2Freplicas%2F1&part=20250728_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.6.10636.altinitytest (altinity build)) '. (RECEIVED_ERROR_FROM_REMOTE_IO_SERVER), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.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 const&, int&&, String const&, unsigned long&&, String const&) @ 0x000000000feda8d9 4. /build/src/IO/HTTPCommon.cpp:104: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x000000000feda6e2 5. /build/src/IO/HTTPCommon.cpp:93: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x000000000feda537 6. /build/src/IO/ReadWriteBufferFromHTTP.cpp:277: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x000000001184a4c4 7. /build/src/IO/ReadWriteBufferFromHTTP.cpp:285: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x000000001184a615 8. /build/src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x000000001184ae59 9. /build/src/IO/ReadWriteBufferFromHTTP.cpp:472: void std::__function::__policy_invoker::__call_impl[abi:se190107]>(std::__function::__policy_storage const*) @ 0x000000001184cedd 10. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001184858b 11. /build/src/IO/ReadWriteBufferFromHTTP.cpp:465: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x000000001184bf0b 12. /build/src/IO/ReadBuffer.h:60: DB::ReadBuffer::next() @ 0x000000000a148c7b 13. /build/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) @ 0x0000000011849fb2 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]>&)>&, 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&) @ 0x0000000011841980 15. /build/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) @ 0x000000001621208e 16. /build/src/Storages/StorageReplicatedMergeTree.cpp:5228: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl[abi:se190107] const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000015f9a5fe 17. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000015ed8bfd 18. /build/src/Storages/StorageReplicatedMergeTree.cpp:2514: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x0000000015ec9aab 19. /build/src/Storages/StorageReplicatedMergeTree.cpp:2349: DB::StorageReplicatedMergeTree::executeLogEntry(DB::ReplicatedMergeTreeLogEntry&) @ 0x0000000015eba91b 20. /build/src/Storages/StorageReplicatedMergeTree.cpp:3876: bool std::__function::__policy_invoker&)>::__call_impl[abi:se190107])::$_1, bool (std::shared_ptr&)>>(std::__function::__policy_storage const*, std::shared_ptr&) @ 0x0000000015f9837e 21. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000165d6fc3 22. /build/src/Storages/StorageReplicatedMergeTree.cpp:3872: DB::StorageReplicatedMergeTree::processQueueEntry(std::shared_ptr) @ 0x0000000015efc18a 23. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001624c1b2 24. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000162f9c70 25. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x00000000162fa55a 26. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc6653 27. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000000fccc4c3 28. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc3d92 29. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fcca080 30. ? @ 0x00007fbc6213eac3 31. ? @ 0x00007fbc621d0850 (version 25.3.6.10636.altinitytest (altinity build)) 2025.07.28 11:53:08.570004 [ 17611 ] {} 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. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Access/AccessControl.cpp:646: DB::AccessControl::authenticate(DB::Credentials const&, Poco::Net::IPAddress const&, DB::ClientInfo const&) const @ 0x0000000013727552 4. /build/src/Interpreters/Session.cpp:371: DB::Session::authenticate(DB::Credentials const&, Poco::Net::SocketAddress const&, std::vector> const&) @ 0x0000000014a6dd4d 5. /build/src/Interpreters/Session.cpp:350: DB::Session::authenticate(String const&, String const&, Poco::Net::SocketAddress const&, std::vector> const&) @ 0x0000000014a6d7b0 6. /build/src/Server/TCPHandler.cpp:1798: DB::TCPHandler::receiveHello() @ 0x00000000168ed801 7. /build/src/Server/TCPHandler.cpp:339: DB::TCPHandler::runImpl() @ 0x00000000168e59e6 8. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 9. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 10. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 11. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 12. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 13. ? @ 0x00007fbc6213eac3 14. ? @ 0x00007fbc621d0850 (version 25.3.6.10636.altinitytest (altinity build)) 2025.07.28 11:53:08.570537 [ 12807 ] {ca96ed73-67d1-4b61-8246-11b2ca9095e0} 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. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Access/AccessControl.cpp:646: DB::AccessControl::authenticate(DB::Credentials const&, Poco::Net::IPAddress const&, DB::ClientInfo const&) const @ 0x0000000013727552 4. /build/src/Interpreters/Session.cpp:371: DB::Session::authenticate(DB::Credentials const&, Poco::Net::SocketAddress const&, std::vector> const&) @ 0x0000000014a6dd4d 5. /build/src/Interpreters/Session.cpp:350: DB::Session::authenticate(String const&, String const&, Poco::Net::SocketAddress const&, std::vector> const&) @ 0x0000000014a6d7b0 6. /build/src/Server/TCPHandler.cpp:1798: DB::TCPHandler::receiveHello() @ 0x00000000168ed801 7. /build/src/Server/TCPHandler.cpp:339: DB::TCPHandler::runImpl() @ 0x00000000168e59e6 8. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 9. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 10. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 11. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 12. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 13. ? @ 0x00007fbc6213eac3 14. ? @ 0x00007fbc621d0850 . (AUTHENTICATION_FAILED) (version 25.3.6.10636.altinitytest (altinity build)) (from [::1]:34600) (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. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:111: DB::readException(DB::ReadBuffer&, String const&, bool) @ 0x000000000fc6e157 3. /build/src/Client/Connection.cpp:1445: DB::Connection::receiveException() const @ 0x00000000167d4127 4. /build/src/Client/Connection.cpp:577: DB::Connection::receiveHello(Poco::Timespan const&) @ 0x00000000167d27a3 5. /build/src/Client/Connection.cpp:235: DB::Connection::connect(DB::ConnectionTimeouts const&) @ 0x00000000167d0891 6. /build/src/Client/Connection.cpp:635: DB::Connection::getServerRevision(DB::ConnectionTimeouts const&) @ 0x00000000167d46b5 7. /build/src/Client/ConnectionEstablisher.cpp:56: DB::ConnectionEstablisher::run(PoolWithFailoverBase::TryResult&, String&, bool) @ 0x00000000167e5d4b 8. /build/src/Client/ConnectionEstablisher.cpp:154: DB::ConnectionEstablisherAsync::Task::run(std::function, std::function) @ 0x00000000167e7751 9. /build/src/Common/AsyncTaskExecutor.cpp:89: DB::AsyncTaskExecutor::Routine::operator()(std::function) @ 0x0000000013bd1892 10. /build/src/Common/Fiber.h:76: boost::context::detail::fiber_record>::run(void*) @ 0x0000000013bd16fa 11. /build/contrib/boost/boost/context/fiber_fcontext.hpp:97: void boost::context::detail::fiber_entry>>(boost::context::detail::transfer_t) @ 0x0000000013bd1621 2025.07.28 11:53:08.572062 [ 17611 ] {} 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. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Access/AccessControl.cpp:646: DB::AccessControl::authenticate(DB::Credentials const&, Poco::Net::IPAddress const&, DB::ClientInfo const&) const @ 0x0000000013727552 4. /build/src/Interpreters/Session.cpp:371: DB::Session::authenticate(DB::Credentials const&, Poco::Net::SocketAddress const&, std::vector> const&) @ 0x0000000014a6dd4d 5. /build/src/Interpreters/Session.cpp:350: DB::Session::authenticate(String const&, String const&, Poco::Net::SocketAddress const&, std::vector> const&) @ 0x0000000014a6d7b0 6. /build/src/Server/TCPHandler.cpp:1798: DB::TCPHandler::receiveHello() @ 0x00000000168ed801 7. /build/src/Server/TCPHandler.cpp:339: DB::TCPHandler::runImpl() @ 0x00000000168e59e6 8. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 9. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 10. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 11. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 12. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 13. ? @ 0x00007fbc6213eac3 14. ? @ 0x00007fbc621d0850 (version 25.3.6.10636.altinitytest (altinity build)) 2025.07.28 11:53:08.573553 [ 12807 ] {} 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. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Access/AccessControl.cpp:646: DB::AccessControl::authenticate(DB::Credentials const&, Poco::Net::IPAddress const&, DB::ClientInfo const&) const @ 0x0000000013727552 4. /build/src/Interpreters/Session.cpp:371: DB::Session::authenticate(DB::Credentials const&, Poco::Net::SocketAddress const&, std::vector> const&) @ 0x0000000014a6dd4d 5. /build/src/Interpreters/Session.cpp:350: DB::Session::authenticate(String const&, String const&, Poco::Net::SocketAddress const&, std::vector> const&) @ 0x0000000014a6d7b0 6. /build/src/Server/TCPHandler.cpp:1798: DB::TCPHandler::receiveHello() @ 0x00000000168ed801 7. /build/src/Server/TCPHandler.cpp:339: DB::TCPHandler::runImpl() @ 0x00000000168e59e6 8. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 9. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 10. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 11. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 12. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 13. ? @ 0x00007fbc6213eac3 14. ? @ 0x00007fbc621d0850 . (AUTHENTICATION_FAILED), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:111: DB::readException(DB::ReadBuffer&, String const&, bool) @ 0x000000000fc6e157 3. /build/src/Client/Connection.cpp:1445: DB::Connection::receiveException() const @ 0x00000000167d4127 4. /build/src/Client/Connection.cpp:577: DB::Connection::receiveHello(Poco::Timespan const&) @ 0x00000000167d27a3 5. /build/src/Client/Connection.cpp:235: DB::Connection::connect(DB::ConnectionTimeouts const&) @ 0x00000000167d0891 6. /build/src/Client/Connection.cpp:635: DB::Connection::getServerRevision(DB::ConnectionTimeouts const&) @ 0x00000000167d46b5 7. /build/src/Client/ConnectionEstablisher.cpp:56: DB::ConnectionEstablisher::run(PoolWithFailoverBase::TryResult&, String&, bool) @ 0x00000000167e5d4b 8. /build/src/Client/ConnectionEstablisher.cpp:154: DB::ConnectionEstablisherAsync::Task::run(std::function, std::function) @ 0x00000000167e7751 9. /build/src/Common/AsyncTaskExecutor.cpp:89: DB::AsyncTaskExecutor::Routine::operator()(std::function) @ 0x0000000013bd1892 10. /build/src/Common/Fiber.h:76: boost::context::detail::fiber_record>::run(void*) @ 0x0000000013bd16fa 11. /build/contrib/boost/boost/context/fiber_fcontext.hpp:97: void boost::context::detail::fiber_entry>>(boost::context::detail::transfer_t) @ 0x0000000013bd1621 2025.07.28 11:53:08.604886 [ 3722 ] {} 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. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000fccaeeb 4. /build/src/Common/ThreadPool.cpp:275: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000fccc813 5. /build/src/Common/ThreadPool.cpp:323: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fcc7bbc 6. /build/src/Common/ThreadPool.cpp:494: ThreadPoolImpl>::scheduleOrThrowOnError(std::function, Priority) @ 0x000000000fcc7a0e 7. /build/src/Common/threadPoolCallbackRunner.h:188: DB::ThreadPoolCallbackRunnerLocal>, std::function>::operator()(std::function&&, Priority, std::optional) @ 0x00000000119df78e 8. /build/src/Interpreters/DatabaseCatalog.cpp:1360: DB::DatabaseCatalog::dropTablesParallel(std::vector, std::allocator>>) @ 0x00000000144fcff9 9. /build/src/Interpreters/DatabaseCatalog.cpp:1382: DB::DatabaseCatalog::dropTableDataTask() @ 0x00000000144fd4fc 10. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000139630d4 11. /build/src/Core/BackgroundSchedulePool.cpp:308: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001396616a 12. /build/src/Core/BackgroundSchedulePool.cpp:171: void std::__function::__policy_invoker::__call_impl[abi:se190107]::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_1>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_1&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001396690a 13. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc3d92 14. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fcca080 15. ? @ 0x00007fbc6213eac3 16. ? @ 0x00007fbc621d0850 (version 25.3.6.10636.altinitytest (altinity build)) 2025.07.28 11:53:08.811661 [ 17611 ] {} TCPHandler: TCPHandler: Code: 81. DB::Exception: Database nonexistent does not exist. (UNKNOWN_DATABASE), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x000000000a06b56b 4. /build/src/Interpreters/DatabaseCatalog.cpp:532: DB::DatabaseCatalog::assertDatabaseExists(String const&) const @ 0x00000000144f312a 5. /build/src/Server/TCPHandler.cpp:342: DB::TCPHandler::runImpl() @ 0x00000000168e5a19 6. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 7. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 8. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 9. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 10. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 11. ? @ 0x00007fbc6213eac3 12. ? @ 0x00007fbc621d0850 (version 25.3.6.10636.altinitytest (altinity build)) 2025.07.28 11:53:08.812894 [ 17611 ] {} ServerErrorHandler: Code: 81. DB::Exception: Database nonexistent does not exist. (UNKNOWN_DATABASE), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x000000000a06b56b 4. /build/src/Interpreters/DatabaseCatalog.cpp:532: DB::DatabaseCatalog::assertDatabaseExists(String const&) const @ 0x00000000144f312a 5. /build/src/Server/TCPHandler.cpp:342: DB::TCPHandler::runImpl() @ 0x00000000168e5a19 6. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 7. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 8. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 9. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 10. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 11. ? @ 0x00007fbc6213eac3 12. ? @ 0x00007fbc621d0850 (version 25.3.6.10636.altinitytest (altinity build)) 2025.07.28 11:53:09.092757 [ 3971 ] {} test_13.rmt2 (7f9b740d-015c-470e-8cc6-8ba33be0dc63): auto DB::StorageReplicatedMergeTree::processQueueEntry(ReplicatedMergeTreeQueue::SelectedEntryPtr)::(anonymous class)::operator()(LogEntryPtr &) const: Code: 86. DB::HTTPException: Received error from remote server http://146b4357c08d:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Ftest%2F01165%2Ftest_13%2Frmt%2Freplicas%2F1&part=20250728_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.6.10636.altinitytest (altinity build)) '. (RECEIVED_ERROR_FROM_REMOTE_IO_SERVER), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.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 const&, int&&, String const&, unsigned long&&, String const&) @ 0x000000000feda8d9 4. /build/src/IO/HTTPCommon.cpp:104: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x000000000feda6e2 5. /build/src/IO/HTTPCommon.cpp:93: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x000000000feda537 6. /build/src/IO/ReadWriteBufferFromHTTP.cpp:277: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x000000001184a4c4 7. /build/src/IO/ReadWriteBufferFromHTTP.cpp:285: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x000000001184a615 8. /build/src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x000000001184ae59 9. /build/src/IO/ReadWriteBufferFromHTTP.cpp:472: void std::__function::__policy_invoker::__call_impl[abi:se190107]>(std::__function::__policy_storage const*) @ 0x000000001184cedd 10. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001184858b 11. /build/src/IO/ReadWriteBufferFromHTTP.cpp:465: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x000000001184bf0b 12. /build/src/IO/ReadBuffer.h:60: DB::ReadBuffer::next() @ 0x000000000a148c7b 13. /build/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) @ 0x0000000011849fb2 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]>&)>&, 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&) @ 0x0000000011841980 15. /build/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) @ 0x000000001621208e 16. /build/src/Storages/StorageReplicatedMergeTree.cpp:5228: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl[abi:se190107] const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000015f9a5fe 17. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000015ed8bfd 18. /build/src/Storages/StorageReplicatedMergeTree.cpp:2514: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x0000000015ec9aab 19. /build/src/Storages/StorageReplicatedMergeTree.cpp:2349: DB::StorageReplicatedMergeTree::executeLogEntry(DB::ReplicatedMergeTreeLogEntry&) @ 0x0000000015eba91b 20. /build/src/Storages/StorageReplicatedMergeTree.cpp:3876: bool std::__function::__policy_invoker&)>::__call_impl[abi:se190107])::$_1, bool (std::shared_ptr&)>>(std::__function::__policy_storage const*, std::shared_ptr&) @ 0x0000000015f9837e 21. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000165d6fc3 22. /build/src/Storages/StorageReplicatedMergeTree.cpp:3872: DB::StorageReplicatedMergeTree::processQueueEntry(std::shared_ptr) @ 0x0000000015efc18a 23. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001624c1b2 24. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000162f9c70 25. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x00000000162fa55a 26. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc6653 27. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000000fccc4c3 28. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc3d92 29. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fcca080 30. ? @ 0x00007fbc6213eac3 31. ? @ 0x00007fbc621d0850 (version 25.3.6.10636.altinitytest (altinity build)) 2025.07.28 11:53:09.165215 [ 5747 ] {9db8f85e-7d54-4518-a8cb-10d41540e9ed} executeQuery: Code: 117. DB::Exception: Duplicate field found while parsing BSONEachRow format: x: (at row 1) : While executing BSONEachRowRowInputFormat. (INCORRECT_DATA) (version 25.3.6.10636.altinitytest (altinity build)) (from [::1]:34696) (comment: 02590_bson_duplicate_column.sql) (query 1, line 1) (in query: select * from format(BSONEachRow, 'x UInt32, y UInt32', x'1a0000001078002a0000001078002a0000001079002a00000000');), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl>>::type>, std::basic_string_view>&&) @ 0x000000000a119c0b 4. /build/src/Processors/Formats/Impl/BSONEachRowRowInputFormat.cpp:806: DB::BSONEachRowRowInputFormat::readRow(std::vector::mutable_ptr, std::allocator::mutable_ptr>>&, DB::RowReadExtension&) @ 0x0000000016a32b62 5. /build/src/Processors/Formats/IRowInputFormat.cpp:143: DB::IRowInputFormat::read() @ 0x0000000016a1fc72 6. /build/src/Processors/Formats/IInputFormat.cpp:19: DB::IInputFormat::generate() @ 0x00000000169c5536 7. /build/src/Processors/ISource.cpp:139: DB::ISource::tryGenerate() @ 0x00000000169a24fa 8. /build/src/Processors/ISource.cpp:108: DB::ISource::work() @ 0x00000000169a21e7 9. /build/src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x00000000169bd00f 10. /build/src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x00000000169b2105 11. /build/src/Processors/Executors/PipelineExecutor.cpp:170: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x00000000169b16a7 12. /build/src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x00000000169c081c 13. /build/src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x00000000169c0978 14. /build/src/TableFunctions/TableFunctionFormat.cpp:125: DB::(anonymous namespace)::TableFunctionFormat::executeImpl(std::shared_ptr const&, std::shared_ptr, String const&, DB::ColumnsDescription, bool) const @ 0x0000000011859cbf 15. /build/src/TableFunctions/ITableFunction.cpp:36: DB::ITableFunction::execute(std::shared_ptr const&, std::shared_ptr, String const&, DB::ColumnsDescription, bool, bool) const @ 0x00000000131e9fc3 16. /build/src/Interpreters/Context.cpp:2501: DB::Context::executeTableFunction(std::shared_ptr const&, std::shared_ptr const&) @ 0x00000000144345b2 17. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:4975: DB::QueryAnalyzer::resolveTableFunction(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&, bool) @ 0x000000001401e9f9 18. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5342: DB::QueryAnalyzer::resolveQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&) @ 0x00000000140452bf 19. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5597: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000140136f0 20. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000140127f9 21. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000014011fce 22. /build/src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000001406ce8a 23. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000014973b42 24. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000001497268d 25. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000014974d24 26. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001492924b 27. /build/src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88641 28. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 29. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 30. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 31. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 2025.07.28 11:53:09.180078 [ 5747 ] {} TCPHandler: Code: 117. DB::Exception: Duplicate field found while parsing BSONEachRow format: x: (at row 1) : While executing BSONEachRowRowInputFormat. (INCORRECT_DATA), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl>>::type>, std::basic_string_view>&&) @ 0x000000000a119c0b 4. /build/src/Processors/Formats/Impl/BSONEachRowRowInputFormat.cpp:806: DB::BSONEachRowRowInputFormat::readRow(std::vector::mutable_ptr, std::allocator::mutable_ptr>>&, DB::RowReadExtension&) @ 0x0000000016a32b62 5. /build/src/Processors/Formats/IRowInputFormat.cpp:143: DB::IRowInputFormat::read() @ 0x0000000016a1fc72 6. /build/src/Processors/Formats/IInputFormat.cpp:19: DB::IInputFormat::generate() @ 0x00000000169c5536 7. /build/src/Processors/ISource.cpp:139: DB::ISource::tryGenerate() @ 0x00000000169a24fa 8. /build/src/Processors/ISource.cpp:108: DB::ISource::work() @ 0x00000000169a21e7 9. /build/src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x00000000169bd00f 10. /build/src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x00000000169b2105 11. /build/src/Processors/Executors/PipelineExecutor.cpp:170: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x00000000169b16a7 12. /build/src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x00000000169c081c 13. /build/src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x00000000169c0978 14. /build/src/TableFunctions/TableFunctionFormat.cpp:125: DB::(anonymous namespace)::TableFunctionFormat::executeImpl(std::shared_ptr const&, std::shared_ptr, String const&, DB::ColumnsDescription, bool) const @ 0x0000000011859cbf 15. /build/src/TableFunctions/ITableFunction.cpp:36: DB::ITableFunction::execute(std::shared_ptr const&, std::shared_ptr, String const&, DB::ColumnsDescription, bool, bool) const @ 0x00000000131e9fc3 16. /build/src/Interpreters/Context.cpp:2501: DB::Context::executeTableFunction(std::shared_ptr const&, std::shared_ptr const&) @ 0x00000000144345b2 17. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:4975: DB::QueryAnalyzer::resolveTableFunction(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&, bool) @ 0x000000001401e9f9 18. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5342: DB::QueryAnalyzer::resolveQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&) @ 0x00000000140452bf 19. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5597: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000140136f0 20. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000140127f9 21. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000014011fce 22. /build/src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000001406ce8a 23. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000014973b42 24. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000001497268d 25. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000014974d24 26. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001492924b 27. /build/src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88641 28. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 29. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 30. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 31. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 2025.07.28 11:53:09.188162 [ 5825 ] {be6e1ad2-c99e-445f-b333-56fad40ab507} executeQuery: Code: 57. DB::Exception: Table test_15.t3 already exists. (TABLE_ALREADY_EXISTS) (version 25.3.6.10636.altinitytest (altinity build)) (from [::1]:34636) (comment: 02691_multiple_joins_backtick_identifiers.sql) (query 13, line 30) (in query: CREATE TABLE t3 (`e` Nullable(Int64), `f` Nullable(String)) engine = Memory;), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000a06a8eb 4. /build/src/Interpreters/InterpreterCreateQuery.cpp:1824: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x0000000014901d53 5. /build/src/Interpreters/InterpreterCreateQuery.cpp:1743: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000148f9aa9 6. /build/src/Interpreters/InterpreterCreateQuery.cpp:2352: DB::InterpreterCreateQuery::execute() @ 0x0000000014905a41 7. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88dc9 8. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 9. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 10. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 11. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 12. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 13. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 14. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 15. ? @ 0x00007fbc6213eac3 16. ? @ 0x00007fbc621d0850 2025.07.28 11:53:09.200688 [ 5825 ] {} TCPHandler: Code: 57. DB::Exception: Table test_15.t3 already exists. (TABLE_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000a06a8eb 4. /build/src/Interpreters/InterpreterCreateQuery.cpp:1824: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x0000000014901d53 5. /build/src/Interpreters/InterpreterCreateQuery.cpp:1743: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000148f9aa9 6. /build/src/Interpreters/InterpreterCreateQuery.cpp:2352: DB::InterpreterCreateQuery::execute() @ 0x0000000014905a41 7. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88dc9 8. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 9. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 10. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 11. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 12. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 13. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 14. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 15. ? @ 0x00007fbc6213eac3 16. ? @ 0x00007fbc621d0850 2025.07.28 11:53:09.643710 [ 4963 ] {2ad50187-b4f6-40dd-81d0-fba1d77b40bd} executeQuery: Code: 1. DB::Exception: Table expression modifiers SAMPLE 1 / 2 are not supported for subquery SELECT 1. (UNSUPPORTED_METHOD) (version 25.3.6.10636.altinitytest (altinity build)) (from [::1]:34726) (comment: 02896_illegal_sampling.sql) (query 1, line 1) (in query: SELECT * FROM (SELECT 1) SAMPLE 1 / 2;), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000a06a8eb 4. /build/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 @ 0x0000000013ff36e8 5. /build/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 @ 0x0000000013feb831 6. /build/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 @ 0x0000000013fedf9d 7. /build/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 @ 0x0000000013feb73d 8. /build/src/Analyzer/QueryTreeBuilder.cpp:144: DB::buildQueryTree(std::shared_ptr, std::shared_ptr) @ 0x0000000013feb3ab 9. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:140: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000014973ac0 10. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000001497268d 11. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000014974d24 12. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001492924b 13. /build/src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88641 14. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 15. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 16. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 17. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 18. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 19. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 20. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 21. ? @ 0x00007fbc6213eac3 22. ? @ 0x00007fbc621d0850 2025.07.28 11:53:09.663523 [ 4963 ] {} 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. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000a06a8eb 4. /build/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 @ 0x0000000013ff36e8 5. /build/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 @ 0x0000000013feb831 6. /build/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 @ 0x0000000013fedf9d 7. /build/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 @ 0x0000000013feb73d 8. /build/src/Analyzer/QueryTreeBuilder.cpp:144: DB::buildQueryTree(std::shared_ptr, std::shared_ptr) @ 0x0000000013feb3ab 9. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:140: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000014973ac0 10. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000001497268d 11. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000014974d24 12. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001492924b 13. /build/src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88641 14. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 15. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 16. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 17. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 18. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 19. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 20. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 21. ? @ 0x00007fbc6213eac3 22. ? @ 0x00007fbc621d0850 2025.07.28 11:53:09.828315 [ 17557 ] {386e43f1-0026-436e-89f6-53a01078344e} executeQuery: Code: 36. DB::Exception: Table test_pjnlliml.dest is already a target of another refreshable materialized view: test_pjnlliml.h. (BAD_ARGUMENTS) (version 25.3.6.10636.altinitytest (altinity build)) (from [::1]:34664) (comment: 02932_refreshable_materialized_views_2.sh) (query 6, line 7) (in query: create materialized view hh refresh every 2 second to dest as select x from src;), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000a06a8eb 4. /build/src/Storages/StorageMaterializedView.cpp:208: DB::StorageMaterializedView::StorageMaterializedView(DB::StorageID const&, std::shared_ptr, DB::ASTCreateQuery const&, DB::ColumnsDescription const&, DB::LoadingStrictnessLevel, String const&, bool) @ 0x0000000015e1ccf0 5. /build/contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: std::shared_ptr std::allocate_shared[abi:se190107], DB::StorageID const&, std::shared_ptr, DB::ASTCreateQuery const&, DB::ColumnsDescription const&, DB::LoadingStrictnessLevel const&, String const&, bool const&, 0>(std::allocator const&, DB::StorageID const&, std::shared_ptr&&, DB::ASTCreateQuery const&, DB::ColumnsDescription const&, DB::LoadingStrictnessLevel const&, String const&, bool const&) @ 0x0000000015e25d5c 6. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:851: std::shared_ptr std::__function::__policy_invoker (DB::StorageFactory::Arguments const&)>::__call_impl[abi:se190107] (DB::StorageFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::StorageFactory::Arguments const&) @ 0x0000000015e24a28 7. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000015d81ea2 8. /build/src/Interpreters/InterpreterCreateQuery.cpp:1945: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x00000000149009bb 9. /build/src/Interpreters/InterpreterCreateQuery.cpp:1743: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000148f9aa9 10. /build/src/Interpreters/InterpreterCreateQuery.cpp:2352: DB::InterpreterCreateQuery::execute() @ 0x0000000014905a41 11. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88dc9 12. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 13. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 14. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 15. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 16. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 17. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 18. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 19. ? @ 0x00007fbc6213eac3 20. ? @ 0x00007fbc621d0850 2025.07.28 11:53:09.830887 [ 17557 ] {} TCPHandler: Code: 36. DB::Exception: Table test_pjnlliml.dest is already a target of another refreshable materialized view: test_pjnlliml.h. (BAD_ARGUMENTS), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000a06a8eb 4. /build/src/Storages/StorageMaterializedView.cpp:208: DB::StorageMaterializedView::StorageMaterializedView(DB::StorageID const&, std::shared_ptr, DB::ASTCreateQuery const&, DB::ColumnsDescription const&, DB::LoadingStrictnessLevel, String const&, bool) @ 0x0000000015e1ccf0 5. /build/contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: std::shared_ptr std::allocate_shared[abi:se190107], DB::StorageID const&, std::shared_ptr, DB::ASTCreateQuery const&, DB::ColumnsDescription const&, DB::LoadingStrictnessLevel const&, String const&, bool const&, 0>(std::allocator const&, DB::StorageID const&, std::shared_ptr&&, DB::ASTCreateQuery const&, DB::ColumnsDescription const&, DB::LoadingStrictnessLevel const&, String const&, bool const&) @ 0x0000000015e25d5c 6. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:851: std::shared_ptr std::__function::__policy_invoker (DB::StorageFactory::Arguments const&)>::__call_impl[abi:se190107] (DB::StorageFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::StorageFactory::Arguments const&) @ 0x0000000015e24a28 7. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000015d81ea2 8. /build/src/Interpreters/InterpreterCreateQuery.cpp:1945: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x00000000149009bb 9. /build/src/Interpreters/InterpreterCreateQuery.cpp:1743: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000148f9aa9 10. /build/src/Interpreters/InterpreterCreateQuery.cpp:2352: DB::InterpreterCreateQuery::execute() @ 0x0000000014905a41 11. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88dc9 12. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 13. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 14. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 15. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 16. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 17. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 18. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 19. ? @ 0x00007fbc6213eac3 20. ? @ 0x00007fbc621d0850 2025.07.28 11:53:10.061240 [ 3967 ] {} test_13.rmt2 (7f9b740d-015c-470e-8cc6-8ba33be0dc63): auto DB::StorageReplicatedMergeTree::processQueueEntry(ReplicatedMergeTreeQueue::SelectedEntryPtr)::(anonymous class)::operator()(LogEntryPtr &) const: Code: 86. DB::HTTPException: Received error from remote server http://146b4357c08d:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Ftest%2F01165%2Ftest_13%2Frmt%2Freplicas%2F1&part=20250728_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.6.10636.altinitytest (altinity build)) '. (RECEIVED_ERROR_FROM_REMOTE_IO_SERVER), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.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 const&, int&&, String const&, unsigned long&&, String const&) @ 0x000000000feda8d9 4. /build/src/IO/HTTPCommon.cpp:104: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x000000000feda6e2 5. /build/src/IO/HTTPCommon.cpp:93: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x000000000feda537 6. /build/src/IO/ReadWriteBufferFromHTTP.cpp:277: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x000000001184a4c4 7. /build/src/IO/ReadWriteBufferFromHTTP.cpp:285: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x000000001184a615 8. /build/src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x000000001184ae59 9. /build/src/IO/ReadWriteBufferFromHTTP.cpp:472: void std::__function::__policy_invoker::__call_impl[abi:se190107]>(std::__function::__policy_storage const*) @ 0x000000001184cedd 10. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001184858b 11. /build/src/IO/ReadWriteBufferFromHTTP.cpp:465: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x000000001184bf0b 12. /build/src/IO/ReadBuffer.h:60: DB::ReadBuffer::next() @ 0x000000000a148c7b 13. /build/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) @ 0x0000000011849fb2 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]>&)>&, 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&) @ 0x0000000011841980 15. /build/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) @ 0x000000001621208e 16. /build/src/Storages/StorageReplicatedMergeTree.cpp:5228: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl[abi:se190107] const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000015f9a5fe 17. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000015ed8bfd 18. /build/src/Storages/StorageReplicatedMergeTree.cpp:2514: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x0000000015ec9aab 19. /build/src/Storages/StorageReplicatedMergeTree.cpp:2349: DB::StorageReplicatedMergeTree::executeLogEntry(DB::ReplicatedMergeTreeLogEntry&) @ 0x0000000015eba91b 20. /build/src/Storages/StorageReplicatedMergeTree.cpp:3876: bool std::__function::__policy_invoker&)>::__call_impl[abi:se190107])::$_1, bool (std::shared_ptr&)>>(std::__function::__policy_storage const*, std::shared_ptr&) @ 0x0000000015f9837e 21. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000165d6fc3 22. /build/src/Storages/StorageReplicatedMergeTree.cpp:3872: DB::StorageReplicatedMergeTree::processQueueEntry(std::shared_ptr) @ 0x0000000015efc18a 23. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001624c1b2 24. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000162f9c70 25. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x00000000162fa55a 26. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc6653 27. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000000fccc4c3 28. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc3d92 29. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fcca080 30. ? @ 0x00007fbc6213eac3 31. ? @ 0x00007fbc621d0850 (version 25.3.6.10636.altinitytest (altinity build)) 2025.07.28 11:53:10.871172 [ 7625 ] {003e322e-f6e8-4a8a-a682-71286e347bb9} executeQuery: Code: 43. DB::Exception: Illegal types Decimal(6, 4) and Decimal(6, 4) of arguments for aggregate function covarPop. (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.6.10636.altinitytest (altinity build)) (from [::1]:34206) (comment: 00700_decimal_empty_aggregates.sql) (query 58, line 80) (in query: SELECT covarPop(a, a), covarPop(b, b), covarPop(c, c) FROM decimal;), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String const&) @ 0x000000001011aceb 4. /build/src/AggregateFunctions/AggregateFunctionStatisticsSimple.h:266: std::shared_ptr DB::createAggregateFunctionStatisticsBinary(String const&, std::vector, std::allocator>> const&, DB::Array const&, DB::Settings const*) @ 0x0000000010c906fa 5. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000131e00dd 6. /build/src/AggregateFunctions/AggregateFunctionFactory.cpp:130: DB::AggregateFunctionFactory::get(String const&, DB::NullsAction, std::vector, std::allocator>> const&, DB::Array const&, DB::AggregateFunctionProperties&) const @ 0x00000000131df0ca 7. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3368: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000014032fed 8. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3838: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000014019a9e 9. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3980: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000014018e31 10. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:4304: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000014042fa7 11. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5605: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000014013749 12. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000140127f9 13. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000014011fce 14. /build/src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000001406ce8a 15. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000014973b42 16. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000001497268d 17. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000014974d24 18. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001492924b 19. /build/src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88641 20. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 21. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 22. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 23. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 24. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 25. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 26. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 27. ? @ 0x00007fbc6213eac3 28. ? @ 0x00007fbc621d0850 2025.07.28 11:53:10.877918 [ 7625 ] {} TCPHandler: Code: 43. DB::Exception: Illegal types Decimal(6, 4) and Decimal(6, 4) of arguments for aggregate function covarPop. (ILLEGAL_TYPE_OF_ARGUMENT), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String const&) @ 0x000000001011aceb 4. /build/src/AggregateFunctions/AggregateFunctionStatisticsSimple.h:266: std::shared_ptr DB::createAggregateFunctionStatisticsBinary(String const&, std::vector, std::allocator>> const&, DB::Array const&, DB::Settings const*) @ 0x0000000010c906fa 5. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000131e00dd 6. /build/src/AggregateFunctions/AggregateFunctionFactory.cpp:130: DB::AggregateFunctionFactory::get(String const&, DB::NullsAction, std::vector, std::allocator>> const&, DB::Array const&, DB::AggregateFunctionProperties&) const @ 0x00000000131df0ca 7. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3368: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000014032fed 8. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3838: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000014019a9e 9. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3980: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000014018e31 10. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:4304: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000014042fa7 11. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5605: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000014013749 12. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000140127f9 13. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000014011fce 14. /build/src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000001406ce8a 15. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000014973b42 16. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000001497268d 17. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000014974d24 18. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001492924b 19. /build/src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88641 20. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 21. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 22. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 23. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 24. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 25. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 26. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 27. ? @ 0x00007fbc6213eac3 28. ? @ 0x00007fbc621d0850 2025.07.28 11:53:10.966596 [ 7625 ] {ac9869cd-02ad-44c7-bf30-2d4738f7db6b} executeQuery: Code: 43. DB::Exception: Illegal types Decimal(6, 4) and Decimal(6, 4) of arguments for aggregate function covarSamp. (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.6.10636.altinitytest (altinity build)) (from [::1]:34206) (comment: 00700_decimal_empty_aggregates.sql) (query 59, line 81) (in query: SELECT covarSamp(a, a), covarSamp(b, b), covarSamp(c, c) FROM decimal;), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String const&) @ 0x000000001011aceb 4. /build/src/AggregateFunctions/AggregateFunctionStatisticsSimple.h:266: std::shared_ptr DB::createAggregateFunctionStatisticsBinary(String const&, std::vector, std::allocator>> const&, DB::Array const&, DB::Settings const*) @ 0x0000000010c9045a 5. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000131e00dd 6. /build/src/AggregateFunctions/AggregateFunctionFactory.cpp:130: DB::AggregateFunctionFactory::get(String const&, DB::NullsAction, std::vector, std::allocator>> const&, DB::Array const&, DB::AggregateFunctionProperties&) const @ 0x00000000131df0ca 7. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3368: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000014032fed 8. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3838: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000014019a9e 9. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3980: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000014018e31 10. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:4304: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000014042fa7 11. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5605: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000014013749 12. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000140127f9 13. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000014011fce 14. /build/src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000001406ce8a 15. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000014973b42 16. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000001497268d 17. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000014974d24 18. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001492924b 19. /build/src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88641 20. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 21. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 22. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 23. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 24. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 25. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 26. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 27. ? @ 0x00007fbc6213eac3 28. ? @ 0x00007fbc621d0850 2025.07.28 11:53:10.977444 [ 7625 ] {} TCPHandler: Code: 43. DB::Exception: Illegal types Decimal(6, 4) and Decimal(6, 4) of arguments for aggregate function covarSamp. (ILLEGAL_TYPE_OF_ARGUMENT), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String const&) @ 0x000000001011aceb 4. /build/src/AggregateFunctions/AggregateFunctionStatisticsSimple.h:266: std::shared_ptr DB::createAggregateFunctionStatisticsBinary(String const&, std::vector, std::allocator>> const&, DB::Array const&, DB::Settings const*) @ 0x0000000010c9045a 5. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000131e00dd 6. /build/src/AggregateFunctions/AggregateFunctionFactory.cpp:130: DB::AggregateFunctionFactory::get(String const&, DB::NullsAction, std::vector, std::allocator>> const&, DB::Array const&, DB::AggregateFunctionProperties&) const @ 0x00000000131df0ca 7. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3368: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000014032fed 8. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3838: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000014019a9e 9. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3980: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000014018e31 10. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:4304: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000014042fa7 11. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5605: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000014013749 12. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000140127f9 13. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000014011fce 14. /build/src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000001406ce8a 15. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000014973b42 16. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000001497268d 17. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000014974d24 18. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001492924b 19. /build/src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88641 20. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 21. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 22. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 23. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 24. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 25. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 26. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 27. ? @ 0x00007fbc6213eac3 28. ? @ 0x00007fbc621d0850 2025.07.28 11:53:11.015069 [ 7625 ] {1d464fcc-33bd-4d90-92c8-7c54b74ee2c7} executeQuery: Code: 43. DB::Exception: Illegal types Decimal(6, 4) and Decimal(6, 4) of arguments for aggregate function corr. (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.6.10636.altinitytest (altinity build)) (from [::1]:34206) (comment: 00700_decimal_empty_aggregates.sql) (query 60, line 82) (in query: SELECT corr(a, a), corr(b, b), corr(c, c) FROM decimal;), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String const&) @ 0x000000001011aceb 4. /build/src/AggregateFunctions/AggregateFunctionStatisticsSimple.h:266: std::shared_ptr DB::createAggregateFunctionStatisticsBinary(String const&, std::vector, std::allocator>> const&, DB::Array const&, DB::Settings const*) @ 0x0000000010d49fea 5. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000131e00dd 6. /build/src/AggregateFunctions/AggregateFunctionFactory.cpp:130: DB::AggregateFunctionFactory::get(String const&, DB::NullsAction, std::vector, std::allocator>> const&, DB::Array const&, DB::AggregateFunctionProperties&) const @ 0x00000000131df0ca 7. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3368: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000014032fed 8. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3838: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000014019a9e 9. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3980: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000014018e31 10. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:4304: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000014042fa7 11. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5605: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000014013749 12. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000140127f9 13. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000014011fce 14. /build/src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000001406ce8a 15. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000014973b42 16. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000001497268d 17. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000014974d24 18. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001492924b 19. /build/src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88641 20. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 21. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 22. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 23. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 24. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 25. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 26. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 27. ? @ 0x00007fbc6213eac3 28. ? @ 0x00007fbc621d0850 2025.07.28 11:53:11.018864 [ 7625 ] {} TCPHandler: Code: 43. DB::Exception: Illegal types Decimal(6, 4) and Decimal(6, 4) of arguments for aggregate function corr. (ILLEGAL_TYPE_OF_ARGUMENT), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String const&) @ 0x000000001011aceb 4. /build/src/AggregateFunctions/AggregateFunctionStatisticsSimple.h:266: std::shared_ptr DB::createAggregateFunctionStatisticsBinary(String const&, std::vector, std::allocator>> const&, DB::Array const&, DB::Settings const*) @ 0x0000000010d49fea 5. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000131e00dd 6. /build/src/AggregateFunctions/AggregateFunctionFactory.cpp:130: DB::AggregateFunctionFactory::get(String const&, DB::NullsAction, std::vector, std::allocator>> const&, DB::Array const&, DB::AggregateFunctionProperties&) const @ 0x00000000131df0ca 7. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3368: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000014032fed 8. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3838: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000014019a9e 9. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3980: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000014018e31 10. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:4304: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000014042fa7 11. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5605: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000014013749 12. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000140127f9 13. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000014011fce 14. /build/src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000001406ce8a 15. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000014973b42 16. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000001497268d 17. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000014974d24 18. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001492924b 19. /build/src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88641 20. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 21. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 22. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 23. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 24. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 25. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 26. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 27. ? @ 0x00007fbc6213eac3 28. ? @ 0x00007fbc621d0850 2025.07.28 11:53:11.084004 [ 3968 ] {} test_13.rmt2 (7f9b740d-015c-470e-8cc6-8ba33be0dc63): auto DB::StorageReplicatedMergeTree::processQueueEntry(ReplicatedMergeTreeQueue::SelectedEntryPtr)::(anonymous class)::operator()(LogEntryPtr &) const: Code: 86. DB::HTTPException: Received error from remote server http://146b4357c08d:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Ftest%2F01165%2Ftest_13%2Frmt%2Freplicas%2F1&part=20250728_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.6.10636.altinitytest (altinity build)) '. (RECEIVED_ERROR_FROM_REMOTE_IO_SERVER), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.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 const&, int&&, String const&, unsigned long&&, String const&) @ 0x000000000feda8d9 4. /build/src/IO/HTTPCommon.cpp:104: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x000000000feda6e2 5. /build/src/IO/HTTPCommon.cpp:93: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x000000000feda537 6. /build/src/IO/ReadWriteBufferFromHTTP.cpp:277: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x000000001184a4c4 7. /build/src/IO/ReadWriteBufferFromHTTP.cpp:285: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x000000001184a615 8. /build/src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x000000001184ae59 9. /build/src/IO/ReadWriteBufferFromHTTP.cpp:472: void std::__function::__policy_invoker::__call_impl[abi:se190107]>(std::__function::__policy_storage const*) @ 0x000000001184cedd 10. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001184858b 11. /build/src/IO/ReadWriteBufferFromHTTP.cpp:465: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x000000001184bf0b 12. /build/src/IO/ReadBuffer.h:60: DB::ReadBuffer::next() @ 0x000000000a148c7b 13. /build/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) @ 0x0000000011849fb2 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]>&)>&, 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&) @ 0x0000000011841980 15. /build/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) @ 0x000000001621208e 16. /build/src/Storages/StorageReplicatedMergeTree.cpp:5228: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl[abi:se190107] const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000015f9a5fe 17. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000015ed8bfd 18. /build/src/Storages/StorageReplicatedMergeTree.cpp:2514: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x0000000015ec9aab 19. /build/src/Storages/StorageReplicatedMergeTree.cpp:2349: DB::StorageReplicatedMergeTree::executeLogEntry(DB::ReplicatedMergeTreeLogEntry&) @ 0x0000000015eba91b 20. /build/src/Storages/StorageReplicatedMergeTree.cpp:3876: bool std::__function::__policy_invoker&)>::__call_impl[abi:se190107])::$_1, bool (std::shared_ptr&)>>(std::__function::__policy_storage const*, std::shared_ptr&) @ 0x0000000015f9837e 21. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000165d6fc3 22. /build/src/Storages/StorageReplicatedMergeTree.cpp:3872: DB::StorageReplicatedMergeTree::processQueueEntry(std::shared_ptr) @ 0x0000000015efc18a 23. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001624c1b2 24. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000162f9c70 25. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x00000000162fa55a 26. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc6653 27. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000000fccc4c3 28. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc3d92 29. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fcca080 30. ? @ 0x00007fbc6213eac3 31. ? @ 0x00007fbc621d0850 (version 25.3.6.10636.altinitytest (altinity build)) 2025.07.28 11:53:11.486902 [ 3970 ] {} test_13.rmt2 (7f9b740d-015c-470e-8cc6-8ba33be0dc63): auto DB::StorageReplicatedMergeTree::processQueueEntry(ReplicatedMergeTreeQueue::SelectedEntryPtr)::(anonymous class)::operator()(LogEntryPtr &) const: Code: 86. DB::HTTPException: Received error from remote server http://146b4357c08d:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Ftest%2F01165%2Ftest_13%2Frmt%2Freplicas%2F1&part=20250728_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.6.10636.altinitytest (altinity build)) '. (RECEIVED_ERROR_FROM_REMOTE_IO_SERVER), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.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 const&, int&&, String const&, unsigned long&&, String const&) @ 0x000000000feda8d9 4. /build/src/IO/HTTPCommon.cpp:104: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x000000000feda6e2 5. /build/src/IO/HTTPCommon.cpp:93: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x000000000feda537 6. /build/src/IO/ReadWriteBufferFromHTTP.cpp:277: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x000000001184a4c4 7. /build/src/IO/ReadWriteBufferFromHTTP.cpp:285: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x000000001184a615 8. /build/src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x000000001184ae59 9. /build/src/IO/ReadWriteBufferFromHTTP.cpp:472: void std::__function::__policy_invoker::__call_impl[abi:se190107]>(std::__function::__policy_storage const*) @ 0x000000001184cedd 10. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001184858b 11. /build/src/IO/ReadWriteBufferFromHTTP.cpp:465: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x000000001184bf0b 12. /build/src/IO/ReadBuffer.h:60: DB::ReadBuffer::next() @ 0x000000000a148c7b 13. /build/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) @ 0x0000000011849fb2 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]>&)>&, 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&) @ 0x0000000011841980 15. /build/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) @ 0x000000001621208e 16. /build/src/Storages/StorageReplicatedMergeTree.cpp:5228: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl[abi:se190107] const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000015f9a5fe 17. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000015ed8bfd 18. /build/src/Storages/StorageReplicatedMergeTree.cpp:2514: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x0000000015ec9aab 19. /build/src/Storages/StorageReplicatedMergeTree.cpp:2349: DB::StorageReplicatedMergeTree::executeLogEntry(DB::ReplicatedMergeTreeLogEntry&) @ 0x0000000015eba91b 20. /build/src/Storages/StorageReplicatedMergeTree.cpp:3876: bool std::__function::__policy_invoker&)>::__call_impl[abi:se190107])::$_1, bool (std::shared_ptr&)>>(std::__function::__policy_storage const*, std::shared_ptr&) @ 0x0000000015f9837e 21. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000165d6fc3 22. /build/src/Storages/StorageReplicatedMergeTree.cpp:3872: DB::StorageReplicatedMergeTree::processQueueEntry(std::shared_ptr) @ 0x0000000015efc18a 23. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001624c1b2 24. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000162f9c70 25. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x00000000162fa55a 26. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc6653 27. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000000fccc4c3 28. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc3d92 29. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fcca080 30. ? @ 0x00007fbc6213eac3 31. ? @ 0x00007fbc621d0850 (version 25.3.6.10636.altinitytest (altinity build)) 2025.07.28 11:53:11.857192 [ 3965 ] {} test_13.rmt2 (7f9b740d-015c-470e-8cc6-8ba33be0dc63): auto DB::StorageReplicatedMergeTree::processQueueEntry(ReplicatedMergeTreeQueue::SelectedEntryPtr)::(anonymous class)::operator()(LogEntryPtr &) const: Code: 86. DB::HTTPException: Received error from remote server http://146b4357c08d:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Ftest%2F01165%2Ftest_13%2Frmt%2Freplicas%2F1&part=20250728_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.6.10636.altinitytest (altinity build)) '. (RECEIVED_ERROR_FROM_REMOTE_IO_SERVER), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.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 const&, int&&, String const&, unsigned long&&, String const&) @ 0x000000000feda8d9 4. /build/src/IO/HTTPCommon.cpp:104: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x000000000feda6e2 5. /build/src/IO/HTTPCommon.cpp:93: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x000000000feda537 6. /build/src/IO/ReadWriteBufferFromHTTP.cpp:277: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x000000001184a4c4 7. /build/src/IO/ReadWriteBufferFromHTTP.cpp:285: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x000000001184a615 8. /build/src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x000000001184ae59 9. /build/src/IO/ReadWriteBufferFromHTTP.cpp:472: void std::__function::__policy_invoker::__call_impl[abi:se190107]>(std::__function::__policy_storage const*) @ 0x000000001184cedd 10. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001184858b 11. /build/src/IO/ReadWriteBufferFromHTTP.cpp:465: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x000000001184bf0b 12. /build/src/IO/ReadBuffer.h:60: DB::ReadBuffer::next() @ 0x000000000a148c7b 13. /build/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) @ 0x0000000011849fb2 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]>&)>&, 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&) @ 0x0000000011841980 15. /build/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) @ 0x000000001621208e 16. /build/src/Storages/StorageReplicatedMergeTree.cpp:5228: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl[abi:se190107] const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000015f9a5fe 17. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000015ed8bfd 18. /build/src/Storages/StorageReplicatedMergeTree.cpp:2514: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x0000000015ec9aab 19. /build/src/Storages/StorageReplicatedMergeTree.cpp:2349: DB::StorageReplicatedMergeTree::executeLogEntry(DB::ReplicatedMergeTreeLogEntry&) @ 0x0000000015eba91b 20. /build/src/Storages/StorageReplicatedMergeTree.cpp:3876: bool std::__function::__policy_invoker&)>::__call_impl[abi:se190107])::$_1, bool (std::shared_ptr&)>>(std::__function::__policy_storage const*, std::shared_ptr&) @ 0x0000000015f9837e 21. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000165d6fc3 22. /build/src/Storages/StorageReplicatedMergeTree.cpp:3872: DB::StorageReplicatedMergeTree::processQueueEntry(std::shared_ptr) @ 0x0000000015efc18a 23. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001624c1b2 24. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000162f9c70 25. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x00000000162fa55a 26. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc6653 27. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000000fccc4c3 28. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc3d92 29. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fcca080 30. ? @ 0x00007fbc6213eac3 31. ? @ 0x00007fbc621d0850 (version 25.3.6.10636.altinitytest (altinity build)) 2025.07.28 11:53:12.776039 [ 3967 ] {} test_13.rmt2 (7f9b740d-015c-470e-8cc6-8ba33be0dc63): auto DB::StorageReplicatedMergeTree::processQueueEntry(ReplicatedMergeTreeQueue::SelectedEntryPtr)::(anonymous class)::operator()(LogEntryPtr &) const: Code: 86. DB::HTTPException: Received error from remote server http://146b4357c08d:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Ftest%2F01165%2Ftest_13%2Frmt%2Freplicas%2F1&part=20250728_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.6.10636.altinitytest (altinity build)) '. (RECEIVED_ERROR_FROM_REMOTE_IO_SERVER), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.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 const&, int&&, String const&, unsigned long&&, String const&) @ 0x000000000feda8d9 4. /build/src/IO/HTTPCommon.cpp:104: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x000000000feda6e2 5. /build/src/IO/HTTPCommon.cpp:93: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x000000000feda537 6. /build/src/IO/ReadWriteBufferFromHTTP.cpp:277: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x000000001184a4c4 7. /build/src/IO/ReadWriteBufferFromHTTP.cpp:285: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x000000001184a615 8. /build/src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x000000001184ae59 9. /build/src/IO/ReadWriteBufferFromHTTP.cpp:472: void std::__function::__policy_invoker::__call_impl[abi:se190107]>(std::__function::__policy_storage const*) @ 0x000000001184cedd 10. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001184858b 11. /build/src/IO/ReadWriteBufferFromHTTP.cpp:465: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x000000001184bf0b 12. /build/src/IO/ReadBuffer.h:60: DB::ReadBuffer::next() @ 0x000000000a148c7b 13. /build/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) @ 0x0000000011849fb2 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]>&)>&, 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&) @ 0x0000000011841980 15. /build/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) @ 0x000000001621208e 16. /build/src/Storages/StorageReplicatedMergeTree.cpp:5228: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl[abi:se190107] const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000015f9a5fe 17. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000015ed8bfd 18. /build/src/Storages/StorageReplicatedMergeTree.cpp:2514: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x0000000015ec9aab 19. /build/src/Storages/StorageReplicatedMergeTree.cpp:2349: DB::StorageReplicatedMergeTree::executeLogEntry(DB::ReplicatedMergeTreeLogEntry&) @ 0x0000000015eba91b 20. /build/src/Storages/StorageReplicatedMergeTree.cpp:3876: bool std::__function::__policy_invoker&)>::__call_impl[abi:se190107])::$_1, bool (std::shared_ptr&)>>(std::__function::__policy_storage const*, std::shared_ptr&) @ 0x0000000015f9837e 21. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000165d6fc3 22. /build/src/Storages/StorageReplicatedMergeTree.cpp:3872: DB::StorageReplicatedMergeTree::processQueueEntry(std::shared_ptr) @ 0x0000000015efc18a 23. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001624c1b2 24. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000162f9c70 25. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x00000000162fa55a 26. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc6653 27. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000000fccc4c3 28. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc3d92 29. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fcca080 30. ? @ 0x00007fbc6213eac3 31. ? @ 0x00007fbc621d0850 (version 25.3.6.10636.altinitytest (altinity build)) 2025.07.28 11:53:12.862226 [ 3539 ] {} RefreshTask: test_pjnlliml.h2: Refresh failed (attempt 1/11): Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(equals(modulo(__table1.x, 2_UInt8), 0_UInt8) :: 2) -> throwIf(equals(modulo(__table1.x, 2_UInt8), 0_UInt8)) UInt8 : 3'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x000000000a06b56b 4. /build/src/Functions/throwIf.cpp:153: DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000e8193b5 5. /build/src/Functions/IFunctionAdaptors.cpp:10: DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000012d995fa 6. /build/src/Functions/IFunction.cpp:353: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d93b52 7. /build/src/Functions/IFunction.cpp:420: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d95059 8. /build/src/Functions/IFunction.cpp:498: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d95c72 9. /build/src/Interpreters/ExpressionActions.cpp:636: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x00000000145176f3 10. /build/src/Processors/Transforms/ExpressionTransform.cpp:25: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x0000000016c0b34c 11. /build/src/Processors/ISimpleTransform.h:33: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000011a9a453 12. /build/src/Processors/ISimpleTransform.cpp:89: DB::ISimpleTransform::work() @ 0x000000001699fca0 13. /build/src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x00000000169bd00f 14. /build/src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x00000000169b2105 15. /build/src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeSingleThread(unsigned long) @ 0x00000000169b23be 16. /build/src/Processors/Executors/PipelineExecutor.cpp:416: void std::__function::__policy_invoker::__call_impl[abi:se190107]>(std::__function::__policy_storage const*) @ 0x00000000169b2e3f 17. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc6653 18. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000000fccc4c3 19. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc3d92 20. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fcca080 21. ? @ 0x00007fbc6213eac3 22. ? @ 0x00007fbc621d0850 Job's origin stack trace: 0. /build/src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000000fc33b84 1. /build/src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000000fcc2ea7 2. /build/src/Common/ThreadPool.cpp:401: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fcc7f1c 3. /build/src/Common/ThreadPool.cpp:494: ThreadPoolImpl>::scheduleOrThrowOnError(std::function, Priority) @ 0x000000000fcc7a0e 4. /build/src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::spawnThreadsImpl() @ 0x00000000169b2c0c 5. /build/src/Processors/Executors/PipelineExecutor.cpp:394: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x00000000169b0ba7 6. /build/src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x00000000169b03f4 7. /build/src/Storages/MaterializedView/RefreshTask.cpp:694: DB::RefreshTask::executeRefreshUnlocked(bool, int) @ 0x00000000167926d8 8. /build/src/Storages/MaterializedView/RefreshTask.cpp:542: DB::RefreshTask::refreshTask() @ 0x000000001678e034 9. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000139630d4 10. /build/src/Core/BackgroundSchedulePool.cpp:308: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001396616a 11. /build/src/Core/BackgroundSchedulePool.cpp:171: void std::__function::__policy_invoker::__call_impl[abi:se190107]::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_1>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_1&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001396690a 12. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc3d92 13. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fcca080 14. ? @ 0x00007fbc6213eac3 15. ? @ 0x00007fbc621d0850 (version 25.3.6.10636.altinitytest (altinity build)) 2025.07.28 11:53:12.920206 [ 17306 ] {71723ce0-d1c1-49d8-a85a-3b25a3d7ccff} executeQuery: Code: 730. DB::Exception: Refresh failed: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(equals(modulo(__table1.x, 2_UInt8), 0_UInt8) :: 2) -> throwIf(equals(modulo(__table1.x, 2_UInt8), 0_UInt8)) UInt8 : 3'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x000000000a06b56b 4. /build/src/Functions/throwIf.cpp:153: DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000e8193b5 5. /build/src/Functions/IFunctionAdaptors.cpp:10: DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000012d995fa 6. /build/src/Functions/IFunction.cpp:353: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d93b52 7. /build/src/Functions/IFunction.cpp:420: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d95059 8. /build/src/Functions/IFunction.cpp:498: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d95c72 9. /build/src/Interpreters/ExpressionActions.cpp:636: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x00000000145176f3 10. /build/src/Processors/Transforms/ExpressionTransform.cpp:25: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x0000000016c0b34c 11. /build/src/Processors/ISimpleTransform.h:33: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000011a9a453 12. /build/src/Processors/ISimpleTransform.cpp:89: DB::ISimpleTransform::work() @ 0x000000001699fca0 13. /build/src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x00000000169bd00f 14. /build/src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x00000000169b2105 15. /build/src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeSingleThread(unsigned long) @ 0x00000000169b23be 16. /build/src/Processors/Executors/PipelineExecutor.cpp:416: void std::__function::__policy_invoker::__call_impl[abi:se190107]>(std::__function::__policy_storage const*) @ 0x00000000169b2e3f 17. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc6653 18. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000000fccc4c3 19. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc3d92 20. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fcca080 21. ? @ 0x00007fbc6213eac3 22. ? @ 0x00007fbc621d0850 Job's origin stack trace: 0. /build/src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000000fc33b84 1. /build/src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000000fcc2ea7 2. /build/src/Common/ThreadPool.cpp:401: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fcc7f1c 3. /build/src/Common/ThreadPool.cpp:494: ThreadPoolImpl>::scheduleOrThrowOnError(std::function, Priority) @ 0x000000000fcc7a0e 4. /build/src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::spawnThreadsImpl() @ 0x00000000169b2c0c 5. /build/src/Processors/Executors/PipelineExecutor.cpp:394: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x00000000169b0ba7 6. /build/src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x00000000169b03f4 7. /build/src/Storages/MaterializedView/RefreshTask.cpp:694: DB::RefreshTask::executeRefreshUnlocked(bool, int) @ 0x00000000167926d8 8. /build/src/Storages/MaterializedView/RefreshTask.cpp:542: DB::RefreshTask::refreshTask() @ 0x000000001678e034 9. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000139630d4 10. /build/src/Core/BackgroundSchedulePool.cpp:308: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001396616a 11. /build/src/Core/BackgroundSchedulePool.cpp:171: void std::__function::__policy_invoker::__call_impl[abi:se190107]::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_1>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_1&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001396690a 12. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc3d92 13. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fcca080 14. ? @ 0x00007fbc6213eac3 15. ? @ 0x00007fbc621d0850 (version 25.3.6.10636.altinitytest (altinity build)). (REFRESH_FAILED) (version 25.3.6.10636.altinitytest (altinity build)) (from [::1]:48468) (comment: 02932_refreshable_materialized_views_2.sh) (query 1, line 1) (in query: system wait view h2;), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000a06a8eb 4. /build/src/Storages/MaterializedView/RefreshTask.cpp:346: DB::RefreshTask::wait()::$_0::operator()() const @ 0x000000001678d2f6 5. /build/src/Storages/MaterializedView/RefreshTask.cpp:356: DB::RefreshTask::wait() @ 0x000000001678cd16 6. /build/src/Interpreters/InterpreterSystemQuery.cpp:725: DB::InterpreterSystemQuery::execute() @ 0x0000000014cb65b8 7. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88dc9 8. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 9. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 10. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 11. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 12. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 13. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 14. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 15. ? @ 0x00007fbc6213eac3 16. ? @ 0x00007fbc621d0850 2025.07.28 11:53:12.928086 [ 17306 ] {} TCPHandler: Code: 730. DB::Exception: Refresh failed: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(equals(modulo(__table1.x, 2_UInt8), 0_UInt8) :: 2) -> throwIf(equals(modulo(__table1.x, 2_UInt8), 0_UInt8)) UInt8 : 3'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x000000000a06b56b 4. /build/src/Functions/throwIf.cpp:153: DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000e8193b5 5. /build/src/Functions/IFunctionAdaptors.cpp:10: DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000012d995fa 6. /build/src/Functions/IFunction.cpp:353: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d93b52 7. /build/src/Functions/IFunction.cpp:420: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d95059 8. /build/src/Functions/IFunction.cpp:498: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d95c72 9. /build/src/Interpreters/ExpressionActions.cpp:636: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x00000000145176f3 10. /build/src/Processors/Transforms/ExpressionTransform.cpp:25: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x0000000016c0b34c 11. /build/src/Processors/ISimpleTransform.h:33: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000011a9a453 12. /build/src/Processors/ISimpleTransform.cpp:89: DB::ISimpleTransform::work() @ 0x000000001699fca0 13. /build/src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x00000000169bd00f 14. /build/src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x00000000169b2105 15. /build/src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeSingleThread(unsigned long) @ 0x00000000169b23be 16. /build/src/Processors/Executors/PipelineExecutor.cpp:416: void std::__function::__policy_invoker::__call_impl[abi:se190107]>(std::__function::__policy_storage const*) @ 0x00000000169b2e3f 17. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc6653 18. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000000fccc4c3 19. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc3d92 20. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fcca080 21. ? @ 0x00007fbc6213eac3 22. ? @ 0x00007fbc621d0850 Job's origin stack trace: 0. /build/src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000000fc33b84 1. /build/src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000000fcc2ea7 2. /build/src/Common/ThreadPool.cpp:401: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fcc7f1c 3. /build/src/Common/ThreadPool.cpp:494: ThreadPoolImpl>::scheduleOrThrowOnError(std::function, Priority) @ 0x000000000fcc7a0e 4. /build/src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::spawnThreadsImpl() @ 0x00000000169b2c0c 5. /build/src/Processors/Executors/PipelineExecutor.cpp:394: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x00000000169b0ba7 6. /build/src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x00000000169b03f4 7. /build/src/Storages/MaterializedView/RefreshTask.cpp:694: DB::RefreshTask::executeRefreshUnlocked(bool, int) @ 0x00000000167926d8 8. /build/src/Storages/MaterializedView/RefreshTask.cpp:542: DB::RefreshTask::refreshTask() @ 0x000000001678e034 9. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000139630d4 10. /build/src/Core/BackgroundSchedulePool.cpp:308: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001396616a 11. /build/src/Core/BackgroundSchedulePool.cpp:171: void std::__function::__policy_invoker::__call_impl[abi:se190107]::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_1>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_1&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001396690a 12. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc3d92 13. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fcca080 14. ? @ 0x00007fbc6213eac3 15. ? @ 0x00007fbc621d0850 (version 25.3.6.10636.altinitytest (altinity build)). (REFRESH_FAILED), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000a06a8eb 4. /build/src/Storages/MaterializedView/RefreshTask.cpp:346: DB::RefreshTask::wait()::$_0::operator()() const @ 0x000000001678d2f6 5. /build/src/Storages/MaterializedView/RefreshTask.cpp:356: DB::RefreshTask::wait() @ 0x000000001678cd16 6. /build/src/Interpreters/InterpreterSystemQuery.cpp:725: DB::InterpreterSystemQuery::execute() @ 0x0000000014cb65b8 7. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88dc9 8. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 9. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 10. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 11. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 12. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 13. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 14. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 15. ? @ 0x00007fbc6213eac3 16. ? @ 0x00007fbc621d0850 2025.07.28 11:53:13.008279 [ 17557 ] {f2b59ef9-b18d-433f-b2dc-4c378d9cb455} executeQuery: Code: 219. DB::Exception: New table appeared in database being dropped or detached. Try again. (DATABASE_NOT_EMPTY) (version 25.3.6.10636.altinitytest (altinity build)) (from [::1]:41074) (comment: 01917_system_data_skipping_indices.sql) (in query: DROP DATABASE IF EXISTS test_zb9a9n1b SYNC ), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000000a074fcb 4. /build/src/Interpreters/DatabaseCatalog.cpp:608: DB::DatabaseCatalog::detachDatabase(std::shared_ptr, String const&, bool, bool) @ 0x00000000144f41b9 5. /build/src/Interpreters/InterpreterDropQuery.cpp:482: DB::InterpreterDropQuery::executeToDatabaseImpl(DB::ASTDropQuery const&, std::shared_ptr&, std::vector, DB::UUIDTag>, std::allocator, DB::UUIDTag>>>&) @ 0x00000000149179be 6. /build/src/Interpreters/InterpreterDropQuery.cpp:363: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x0000000014913988 7. /build/src/Interpreters/InterpreterDropQuery.cpp:99: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000014913142 8. /build/src/Interpreters/InterpreterDropQuery.cpp:72: DB::InterpreterDropQuery::execute() @ 0x0000000014912b65 9. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88dc9 10. /build/src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x0000000014c8ca7b 11. /build/src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000001686da12 12. /build/src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x0000000016870807 13. /build/src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x0000000016907e99 14. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 15. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 16. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 17. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 18. ? @ 0x00007fbc6213eac3 19. ? @ 0x00007fbc621d0850 2025.07.28 11:53:13.013522 [ 17557 ] {f2b59ef9-b18d-433f-b2dc-4c378d9cb455} 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. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000000a074fcb 4. /build/src/Interpreters/DatabaseCatalog.cpp:608: DB::DatabaseCatalog::detachDatabase(std::shared_ptr, String const&, bool, bool) @ 0x00000000144f41b9 5. /build/src/Interpreters/InterpreterDropQuery.cpp:482: DB::InterpreterDropQuery::executeToDatabaseImpl(DB::ASTDropQuery const&, std::shared_ptr&, std::vector, DB::UUIDTag>, std::allocator, DB::UUIDTag>>>&) @ 0x00000000149179be 6. /build/src/Interpreters/InterpreterDropQuery.cpp:363: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x0000000014913988 7. /build/src/Interpreters/InterpreterDropQuery.cpp:99: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000014913142 8. /build/src/Interpreters/InterpreterDropQuery.cpp:72: DB::InterpreterDropQuery::execute() @ 0x0000000014912b65 9. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88dc9 10. /build/src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x0000000014c8ca7b 11. /build/src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000001686da12 12. /build/src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x0000000016870807 13. /build/src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x0000000016907e99 14. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 15. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 16. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 17. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 18. ? @ 0x00007fbc6213eac3 19. ? @ 0x00007fbc621d0850 (version 25.3.6.10636.altinitytest (altinity build)) 2025.07.28 11:53:13.184234 [ 3555 ] {} RefreshTask: test_pjnlliml.h2: Refresh failed (attempt 2/11): Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(equals(modulo(__table1.x, 2_UInt8), 0_UInt8) :: 2) -> throwIf(equals(modulo(__table1.x, 2_UInt8), 0_UInt8)) UInt8 : 3'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x000000000a06b56b 4. /build/src/Functions/throwIf.cpp:153: DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000e8193b5 5. /build/src/Functions/IFunctionAdaptors.cpp:10: DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000012d995fa 6. /build/src/Functions/IFunction.cpp:353: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d93b52 7. /build/src/Functions/IFunction.cpp:420: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d95059 8. /build/src/Functions/IFunction.cpp:498: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d95c72 9. /build/src/Interpreters/ExpressionActions.cpp:636: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x00000000145176f3 10. /build/src/Processors/Transforms/ExpressionTransform.cpp:25: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x0000000016c0b34c 11. /build/src/Processors/ISimpleTransform.h:33: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000011a9a453 12. /build/src/Processors/ISimpleTransform.cpp:89: DB::ISimpleTransform::work() @ 0x000000001699fca0 13. /build/src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x00000000169bd00f 14. /build/src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x00000000169b2105 15. /build/src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeSingleThread(unsigned long) @ 0x00000000169b23be 16. /build/src/Processors/Executors/PipelineExecutor.cpp:416: void std::__function::__policy_invoker::__call_impl[abi:se190107]>(std::__function::__policy_storage const*) @ 0x00000000169b2e3f 17. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc6653 18. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000000fccc4c3 19. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc3d92 20. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fcca080 21. ? @ 0x00007fbc6213eac3 22. ? @ 0x00007fbc621d0850 Job's origin stack trace: 0. /build/src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000000fc33b84 1. /build/src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000000fcc2ea7 2. /build/src/Common/ThreadPool.cpp:401: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fcc7f1c 3. /build/src/Common/ThreadPool.cpp:494: ThreadPoolImpl>::scheduleOrThrowOnError(std::function, Priority) @ 0x000000000fcc7a0e 4. /build/src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::spawnThreadsImpl() @ 0x00000000169b2c0c 5. /build/src/Processors/Executors/PipelineExecutor.cpp:394: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x00000000169b0ba7 6. /build/src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x00000000169b03f4 7. /build/src/Storages/MaterializedView/RefreshTask.cpp:694: DB::RefreshTask::executeRefreshUnlocked(bool, int) @ 0x00000000167926d8 8. /build/src/Storages/MaterializedView/RefreshTask.cpp:542: DB::RefreshTask::refreshTask() @ 0x000000001678e034 9. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000139630d4 10. /build/src/Core/BackgroundSchedulePool.cpp:308: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001396616a 11. /build/src/Core/BackgroundSchedulePool.cpp:171: void std::__function::__policy_invoker::__call_impl[abi:se190107]::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_1>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_1&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001396690a 12. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc3d92 13. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fcca080 14. ? @ 0x00007fbc6213eac3 15. ? @ 0x00007fbc621d0850 (version 25.3.6.10636.altinitytest (altinity build)) 2025.07.28 11:53:13.562887 [ 3969 ] {} test_13.rmt2 (7f9b740d-015c-470e-8cc6-8ba33be0dc63): auto DB::StorageReplicatedMergeTree::processQueueEntry(ReplicatedMergeTreeQueue::SelectedEntryPtr)::(anonymous class)::operator()(LogEntryPtr &) const: Code: 86. DB::HTTPException: Received error from remote server http://146b4357c08d:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Ftest%2F01165%2Ftest_13%2Frmt%2Freplicas%2F1&part=20250728_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.6.10636.altinitytest (altinity build)) '. (RECEIVED_ERROR_FROM_REMOTE_IO_SERVER), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.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 const&, int&&, String const&, unsigned long&&, String const&) @ 0x000000000feda8d9 4. /build/src/IO/HTTPCommon.cpp:104: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x000000000feda6e2 5. /build/src/IO/HTTPCommon.cpp:93: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x000000000feda537 6. /build/src/IO/ReadWriteBufferFromHTTP.cpp:277: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x000000001184a4c4 7. /build/src/IO/ReadWriteBufferFromHTTP.cpp:285: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x000000001184a615 8. /build/src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x000000001184ae59 9. /build/src/IO/ReadWriteBufferFromHTTP.cpp:472: void std::__function::__policy_invoker::__call_impl[abi:se190107]>(std::__function::__policy_storage const*) @ 0x000000001184cedd 10. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001184858b 11. /build/src/IO/ReadWriteBufferFromHTTP.cpp:465: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x000000001184bf0b 12. /build/src/IO/ReadBuffer.h:60: DB::ReadBuffer::next() @ 0x000000000a148c7b 13. /build/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) @ 0x0000000011849fb2 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]>&)>&, 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&) @ 0x0000000011841980 15. /build/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) @ 0x000000001621208e 16. /build/src/Storages/StorageReplicatedMergeTree.cpp:5228: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl[abi:se190107] const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000015f9a5fe 17. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000015ed8bfd 18. /build/src/Storages/StorageReplicatedMergeTree.cpp:2514: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x0000000015ec9aab 19. /build/src/Storages/StorageReplicatedMergeTree.cpp:2349: DB::StorageReplicatedMergeTree::executeLogEntry(DB::ReplicatedMergeTreeLogEntry&) @ 0x0000000015eba91b 20. /build/src/Storages/StorageReplicatedMergeTree.cpp:3876: bool std::__function::__policy_invoker&)>::__call_impl[abi:se190107])::$_1, bool (std::shared_ptr&)>>(std::__function::__policy_storage const*, std::shared_ptr&) @ 0x0000000015f9837e 21. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000165d6fc3 22. /build/src/Storages/StorageReplicatedMergeTree.cpp:3872: DB::StorageReplicatedMergeTree::processQueueEntry(std::shared_ptr) @ 0x0000000015efc18a 23. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001624c1b2 24. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000162f9c70 25. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x00000000162fa55a 26. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc6653 27. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000000fccc4c3 28. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc3d92 29. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fcca080 30. ? @ 0x00007fbc6213eac3 31. ? @ 0x00007fbc621d0850 (version 25.3.6.10636.altinitytest (altinity build)) 2025.07.28 11:53:13.565355 [ 3367 ] {} RefreshTask: test_pjnlliml.h2: Refresh failed (attempt 3/11): Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(equals(modulo(__table1.x, 2_UInt8), 0_UInt8) :: 2) -> throwIf(equals(modulo(__table1.x, 2_UInt8), 0_UInt8)) UInt8 : 3'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x000000000a06b56b 4. /build/src/Functions/throwIf.cpp:153: DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000e8193b5 5. /build/src/Functions/IFunctionAdaptors.cpp:10: DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000012d995fa 6. /build/src/Functions/IFunction.cpp:353: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d93b52 7. /build/src/Functions/IFunction.cpp:420: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d95059 8. /build/src/Functions/IFunction.cpp:498: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d95c72 9. /build/src/Interpreters/ExpressionActions.cpp:636: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x00000000145176f3 10. /build/src/Processors/Transforms/ExpressionTransform.cpp:25: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x0000000016c0b34c 11. /build/src/Processors/ISimpleTransform.h:33: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000011a9a453 12. /build/src/Processors/ISimpleTransform.cpp:89: DB::ISimpleTransform::work() @ 0x000000001699fca0 13. /build/src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x00000000169bd00f 14. /build/src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x00000000169b2105 15. /build/src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeSingleThread(unsigned long) @ 0x00000000169b23be 16. /build/src/Processors/Executors/PipelineExecutor.cpp:416: void std::__function::__policy_invoker::__call_impl[abi:se190107]>(std::__function::__policy_storage const*) @ 0x00000000169b2e3f 17. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc6653 18. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000000fccc4c3 19. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc3d92 20. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fcca080 21. ? @ 0x00007fbc6213eac3 22. ? @ 0x00007fbc621d0850 Job's origin stack trace: 0. /build/src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000000fc33b84 1. /build/src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000000fcc2ea7 2. /build/src/Common/ThreadPool.cpp:401: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fcc7f1c 3. /build/src/Common/ThreadPool.cpp:494: ThreadPoolImpl>::scheduleOrThrowOnError(std::function, Priority) @ 0x000000000fcc7a0e 4. /build/src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::spawnThreadsImpl() @ 0x00000000169b2c0c 5. /build/src/Processors/Executors/PipelineExecutor.cpp:394: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x00000000169b0ba7 6. /build/src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x00000000169b03f4 7. /build/src/Storages/MaterializedView/RefreshTask.cpp:694: DB::RefreshTask::executeRefreshUnlocked(bool, int) @ 0x00000000167926d8 8. /build/src/Storages/MaterializedView/RefreshTask.cpp:542: DB::RefreshTask::refreshTask() @ 0x000000001678e034 9. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000139630d4 10. /build/src/Core/BackgroundSchedulePool.cpp:308: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001396616a 11. /build/src/Core/BackgroundSchedulePool.cpp:171: void std::__function::__policy_invoker::__call_impl[abi:se190107]::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_1>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_1&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001396690a 12. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc3d92 13. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fcca080 14. ? @ 0x00007fbc6213eac3 15. ? @ 0x00007fbc621d0850 (version 25.3.6.10636.altinitytest (altinity build)) 2025.07.28 11:53:13.621260 [ 5292 ] {fffd7a6b-3139-4354-9450-28bf0afd7755} DistributedSink: Structure does not match (remote: key Nullable(UInt64) Nullable(size = 0, UInt64(size = 0), UInt8(size = 0)), local: key UInt64 UInt64(size = 1)), implicit conversion will be done. 2025.07.28 11:53:13.701048 [ 17557 ] {489ee0f0-0ff3-411f-ad0d-45cce08fc429} 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.6.10636.altinitytest (altinity build)). You can specify the structure manually: (in file/uri /var/lib/clickhouse/user_files/02267_file_globs_schema_inference_test_15_data4.jsonl). (CANNOT_EXTRACT_TABLE_STRUCTURE) (version 25.3.6.10636.altinitytest (altinity build)) (from [::1]:48514) (comment: 02267_file_globs_schema_inference.sh) (query 1, line 1) (in query: select * from file('02267_file_globs_schema_inference_test_15_data*.jsonl') settings schema_inference_use_cache_for_file=0), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&, String&) @ 0x000000000e65d7ab 4. /build/src/Formats/ReadSchemaUtils.cpp:287: DB::readSchemaFromFormatImpl(std::optional, std::optional const&, DB::IReadBufferIterator&, std::shared_ptr const&) @ 0x000000001697997b 5. /build/src/Formats/ReadSchemaUtils.cpp:548: DB::readSchemaFromFormat(String const&, std::optional const&, DB::IReadBufferIterator&, std::shared_ptr const&) @ 0x000000001697a742 6. /build/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&) @ 0x0000000015d86dc1 7. /build/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&) @ 0x0000000015d8741c 8. /build/src/Storages/StorageFile.cpp:1122: DB::StorageFile::setStorageMetadata(DB::StorageFile::CommonArguments) @ 0x0000000015d88292 9. /build/src/Storages/StorageFile.cpp:1063: DB::StorageFile::StorageFile(String const&, String const&, DB::StorageFile::CommonArguments) @ 0x0000000015d89a79 10. /build/src/Storages/StorageFile.cpp:1067: DB::StorageFile::StorageFile(String const&, String const&, bool, DB::StorageFile::CommonArguments) @ 0x0000000015d8a0dc 11. /build/contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: std::shared_ptr std::allocate_shared[abi:se190107], String const&, String, bool, DB::StorageFile::CommonArguments&, 0>(std::allocator const&, String const&, String&&, bool&&, DB::StorageFile::CommonArguments&) @ 0x00000000118256ca 12. /build/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 @ 0x0000000011823998 13. /build/src/TableFunctions/ITableFunctionFileLike.cpp:96: DB::ITableFunctionFileLike::executeImpl(std::shared_ptr const&, std::shared_ptr, String const&, DB::ColumnsDescription, bool) const @ 0x000000001182689c 14. /build/src/TableFunctions/ITableFunction.cpp:36: DB::ITableFunction::execute(std::shared_ptr const&, std::shared_ptr, String const&, DB::ColumnsDescription, bool, bool) const @ 0x00000000131e9fc3 15. /build/src/Interpreters/Context.cpp:2501: DB::Context::executeTableFunction(std::shared_ptr const&, std::shared_ptr const&) @ 0x00000000144345b2 16. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:4975: DB::QueryAnalyzer::resolveTableFunction(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&, bool) @ 0x000000001401e9f9 17. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5342: DB::QueryAnalyzer::resolveQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&) @ 0x00000000140452bf 18. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5597: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000140136f0 19. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000140127f9 20. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000014011fce 21. /build/src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000001406ce8a 22. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000014973b42 23. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000001497268d 24. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000014974d24 25. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001492924b 26. /build/src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88641 27. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 28. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 29. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 30. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 31. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 2025.07.28 11:53:13.730279 [ 17557 ] {} 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.6.10636.altinitytest (altinity build)). You can specify the structure manually: (in file/uri /var/lib/clickhouse/user_files/02267_file_globs_schema_inference_test_15_data4.jsonl). (CANNOT_EXTRACT_TABLE_STRUCTURE), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&, String&) @ 0x000000000e65d7ab 4. /build/src/Formats/ReadSchemaUtils.cpp:287: DB::readSchemaFromFormatImpl(std::optional, std::optional const&, DB::IReadBufferIterator&, std::shared_ptr const&) @ 0x000000001697997b 5. /build/src/Formats/ReadSchemaUtils.cpp:548: DB::readSchemaFromFormat(String const&, std::optional const&, DB::IReadBufferIterator&, std::shared_ptr const&) @ 0x000000001697a742 6. /build/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&) @ 0x0000000015d86dc1 7. /build/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&) @ 0x0000000015d8741c 8. /build/src/Storages/StorageFile.cpp:1122: DB::StorageFile::setStorageMetadata(DB::StorageFile::CommonArguments) @ 0x0000000015d88292 9. /build/src/Storages/StorageFile.cpp:1063: DB::StorageFile::StorageFile(String const&, String const&, DB::StorageFile::CommonArguments) @ 0x0000000015d89a79 10. /build/src/Storages/StorageFile.cpp:1067: DB::StorageFile::StorageFile(String const&, String const&, bool, DB::StorageFile::CommonArguments) @ 0x0000000015d8a0dc 11. /build/contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: std::shared_ptr std::allocate_shared[abi:se190107], String const&, String, bool, DB::StorageFile::CommonArguments&, 0>(std::allocator const&, String const&, String&&, bool&&, DB::StorageFile::CommonArguments&) @ 0x00000000118256ca 12. /build/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 @ 0x0000000011823998 13. /build/src/TableFunctions/ITableFunctionFileLike.cpp:96: DB::ITableFunctionFileLike::executeImpl(std::shared_ptr const&, std::shared_ptr, String const&, DB::ColumnsDescription, bool) const @ 0x000000001182689c 14. /build/src/TableFunctions/ITableFunction.cpp:36: DB::ITableFunction::execute(std::shared_ptr const&, std::shared_ptr, String const&, DB::ColumnsDescription, bool, bool) const @ 0x00000000131e9fc3 15. /build/src/Interpreters/Context.cpp:2501: DB::Context::executeTableFunction(std::shared_ptr const&, std::shared_ptr const&) @ 0x00000000144345b2 16. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:4975: DB::QueryAnalyzer::resolveTableFunction(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&, bool) @ 0x000000001401e9f9 17. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5342: DB::QueryAnalyzer::resolveQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&) @ 0x00000000140452bf 18. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5597: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000140136f0 19. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000140127f9 20. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000014011fce 21. /build/src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000001406ce8a 22. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000014973b42 23. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000001497268d 24. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000014974d24 25. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001492924b 26. /build/src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88641 27. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 28. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 29. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 30. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 31. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 2025.07.28 11:53:14.327991 [ 3977 ] {} test_13.rmt2 (7f9b740d-015c-470e-8cc6-8ba33be0dc63): auto DB::StorageReplicatedMergeTree::processQueueEntry(ReplicatedMergeTreeQueue::SelectedEntryPtr)::(anonymous class)::operator()(LogEntryPtr &) const: Code: 86. DB::HTTPException: Received error from remote server http://146b4357c08d:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Ftest%2F01165%2Ftest_13%2Frmt%2Freplicas%2F1&part=20250728_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.6.10636.altinitytest (altinity build)) '. (RECEIVED_ERROR_FROM_REMOTE_IO_SERVER), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.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 const&, int&&, String const&, unsigned long&&, String const&) @ 0x000000000feda8d9 4. /build/src/IO/HTTPCommon.cpp:104: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x000000000feda6e2 5. /build/src/IO/HTTPCommon.cpp:93: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x000000000feda537 6. /build/src/IO/ReadWriteBufferFromHTTP.cpp:277: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x000000001184a4c4 7. /build/src/IO/ReadWriteBufferFromHTTP.cpp:285: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x000000001184a615 8. /build/src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x000000001184ae59 9. /build/src/IO/ReadWriteBufferFromHTTP.cpp:472: void std::__function::__policy_invoker::__call_impl[abi:se190107]>(std::__function::__policy_storage const*) @ 0x000000001184cedd 10. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001184858b 11. /build/src/IO/ReadWriteBufferFromHTTP.cpp:465: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x000000001184bf0b 12. /build/src/IO/ReadBuffer.h:60: DB::ReadBuffer::next() @ 0x000000000a148c7b 13. /build/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) @ 0x0000000011849fb2 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]>&)>&, 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&) @ 0x0000000011841980 15. /build/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) @ 0x000000001621208e 16. /build/src/Storages/StorageReplicatedMergeTree.cpp:5228: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl[abi:se190107] const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000015f9a5fe 17. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000015ed8bfd 18. /build/src/Storages/StorageReplicatedMergeTree.cpp:2514: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x0000000015ec9aab 19. /build/src/Storages/StorageReplicatedMergeTree.cpp:2349: DB::StorageReplicatedMergeTree::executeLogEntry(DB::ReplicatedMergeTreeLogEntry&) @ 0x0000000015eba91b 20. /build/src/Storages/StorageReplicatedMergeTree.cpp:3876: bool std::__function::__policy_invoker&)>::__call_impl[abi:se190107])::$_1, bool (std::shared_ptr&)>>(std::__function::__policy_storage const*, std::shared_ptr&) @ 0x0000000015f9837e 21. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000165d6fc3 22. /build/src/Storages/StorageReplicatedMergeTree.cpp:3872: DB::StorageReplicatedMergeTree::processQueueEntry(std::shared_ptr) @ 0x0000000015efc18a 23. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001624c1b2 24. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000162f9c70 25. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x00000000162fa55a 26. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc6653 27. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000000fccc4c3 28. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc3d92 29. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fcca080 30. ? @ 0x00007fbc6213eac3 31. ? @ 0x00007fbc621d0850 (version 25.3.6.10636.altinitytest (altinity build)) 2025.07.28 11:53:14.664291 [ 17207 ] {cfd6ce4d-0799-4363-b0e8-9c6a372fcde5} executeQuery: Code: 675. DB::Exception: Invalid IPv4 value: In scope SELECT IPv4StringToNum('test'). (CANNOT_PARSE_IPV4) (version 25.3.6.10636.altinitytest (altinity build)) (from [::1]:48582) (comment: 02234_cast_to_ip_address.sql) (query 2, line 3) (in query: SELECT IPv4StringToNum('test');), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000000a074fcb 4. /build/src/Functions/FunctionsCodingIP.h:277: COW::immutable_ptr DB::convertToIPv4<(DB::IPStringToNumExceptionMode)0, DB::ColumnVector>(COW::immutable_ptr, DB::PODArray, 63ul, 64ul> const*) @ 0x000000000a1107a8 5. /build/src/Functions/FunctionsCodingIP.cpp:512: DB::FunctionIPv4StringToNum<(DB::IPStringToNumExceptionMode)0>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000a10f58a 6. /build/src/Functions/IFunction.h:437: DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000a069f2a 7. /build/src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000012d9965a 8. /build/src/Functions/IFunction.cpp:351: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d93b02 9. /build/src/Functions/IFunction.cpp:177: DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d93698 10. /build/src/Functions/IFunction.cpp:343: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d93aad 11. /build/src/Functions/IFunction.cpp:420: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d95059 12. /build/src/Functions/IFunction.cpp:498: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d95c72 13. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3567: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000014034494 14. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3838: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000014019a9e 15. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3980: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000014018e31 16. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:4304: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000014042fa7 17. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5605: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000014013749 18. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000140127f9 19. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000014011fce 20. /build/src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000001406ce8a 21. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000014973b42 22. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000001497268d 23. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000014974d24 24. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001492924b 25. /build/src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88641 26. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 27. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 28. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 29. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 30. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 31. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 2025.07.28 11:53:14.671113 [ 17207 ] {} TCPHandler: Code: 675. DB::Exception: Invalid IPv4 value: In scope SELECT IPv4StringToNum('test'). (CANNOT_PARSE_IPV4), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000000a074fcb 4. /build/src/Functions/FunctionsCodingIP.h:277: COW::immutable_ptr DB::convertToIPv4<(DB::IPStringToNumExceptionMode)0, DB::ColumnVector>(COW::immutable_ptr, DB::PODArray, 63ul, 64ul> const*) @ 0x000000000a1107a8 5. /build/src/Functions/FunctionsCodingIP.cpp:512: DB::FunctionIPv4StringToNum<(DB::IPStringToNumExceptionMode)0>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000a10f58a 6. /build/src/Functions/IFunction.h:437: DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000a069f2a 7. /build/src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000012d9965a 8. /build/src/Functions/IFunction.cpp:351: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d93b02 9. /build/src/Functions/IFunction.cpp:177: DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d93698 10. /build/src/Functions/IFunction.cpp:343: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d93aad 11. /build/src/Functions/IFunction.cpp:420: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d95059 12. /build/src/Functions/IFunction.cpp:498: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d95c72 13. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3567: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000014034494 14. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3838: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000014019a9e 15. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3980: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000014018e31 16. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:4304: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000014042fa7 17. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5605: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000014013749 18. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000140127f9 19. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000014011fce 20. /build/src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000001406ce8a 21. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000014973b42 22. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000001497268d 23. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000014974d24 24. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001492924b 25. /build/src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88641 26. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 27. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 28. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 29. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 30. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 31. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 2025.07.28 11:53:14.843548 [ 17208 ] {6aa43f01-df86-4105-8c18-b8c470d776aa} executeQuery: Code: 475. DB::Exception: WITH FILL STEP value cannot be negative for sorting in ascending direction. (INVALID_WITH_FILL_EXPRESSION) (version 25.3.6.10636.altinitytest (altinity build)) (from [::1]:48408) (comment: 00995_order_by_with_fill.sql) (query 16, line 34) (in query: SELECT * FROM fill ORDER BY a WITH FILL STEP -1;), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000000a074fcb 4. /build/src/Planner/PlannerSorting.cpp:113: DB::extractSortDescription(std::shared_ptr const&, DB::PlannerContext const&) @ 0x00000000149c91e4 5. /build/src/Planner/Planner.cpp:340: DB::Planner::buildPlanForQueryNode() @ 0x000000001497a96b 6. /build/src/Planner/Planner.cpp:1308: DB::Planner::buildQueryPlanIfNeeded() @ 0x000000001497685c 7. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:255: DB::InterpreterSelectQueryAnalyzer::getQueryPlan() @ 0x000000001497476d 8. /build/src/Interpreters/executeQuery.cpp:1405: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88806 9. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 10. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 11. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 12. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 13. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 14. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 15. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 16. ? @ 0x00007fbc6213eac3 17. ? @ 0x00007fbc621d0850 2025.07.28 11:53:14.847102 [ 17208 ] {} TCPHandler: Code: 475. DB::Exception: WITH FILL STEP value cannot be negative for sorting in ascending direction. (INVALID_WITH_FILL_EXPRESSION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000000a074fcb 4. /build/src/Planner/PlannerSorting.cpp:113: DB::extractSortDescription(std::shared_ptr const&, DB::PlannerContext const&) @ 0x00000000149c91e4 5. /build/src/Planner/Planner.cpp:340: DB::Planner::buildPlanForQueryNode() @ 0x000000001497a96b 6. /build/src/Planner/Planner.cpp:1308: DB::Planner::buildQueryPlanIfNeeded() @ 0x000000001497685c 7. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:255: DB::InterpreterSelectQueryAnalyzer::getQueryPlan() @ 0x000000001497476d 8. /build/src/Interpreters/executeQuery.cpp:1405: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88806 9. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 10. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 11. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 12. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 13. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 14. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 15. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 16. ? @ 0x00007fbc6213eac3 17. ? @ 0x00007fbc621d0850 2025.07.28 11:53:14.865984 [ 3965 ] {} test_13.rmt2 (7f9b740d-015c-470e-8cc6-8ba33be0dc63): auto DB::StorageReplicatedMergeTree::processQueueEntry(ReplicatedMergeTreeQueue::SelectedEntryPtr)::(anonymous class)::operator()(LogEntryPtr &) const: Code: 86. DB::HTTPException: Received error from remote server http://146b4357c08d:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Ftest%2F01165%2Ftest_13%2Frmt%2Freplicas%2F1&part=20250728_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.6.10636.altinitytest (altinity build)) '. (RECEIVED_ERROR_FROM_REMOTE_IO_SERVER), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.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 const&, int&&, String const&, unsigned long&&, String const&) @ 0x000000000feda8d9 4. /build/src/IO/HTTPCommon.cpp:104: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x000000000feda6e2 5. /build/src/IO/HTTPCommon.cpp:93: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x000000000feda537 6. /build/src/IO/ReadWriteBufferFromHTTP.cpp:277: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x000000001184a4c4 7. /build/src/IO/ReadWriteBufferFromHTTP.cpp:285: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x000000001184a615 8. /build/src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x000000001184ae59 9. /build/src/IO/ReadWriteBufferFromHTTP.cpp:472: void std::__function::__policy_invoker::__call_impl[abi:se190107]>(std::__function::__policy_storage const*) @ 0x000000001184cedd 10. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001184858b 11. /build/src/IO/ReadWriteBufferFromHTTP.cpp:465: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x000000001184bf0b 12. /build/src/IO/ReadBuffer.h:60: DB::ReadBuffer::next() @ 0x000000000a148c7b 13. /build/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) @ 0x0000000011849fb2 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]>&)>&, 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&) @ 0x0000000011841980 15. /build/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) @ 0x000000001621208e 16. /build/src/Storages/StorageReplicatedMergeTree.cpp:5228: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl[abi:se190107] const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000015f9a5fe 17. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000015ed8bfd 18. /build/src/Storages/StorageReplicatedMergeTree.cpp:2514: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x0000000015ec9aab 19. /build/src/Storages/StorageReplicatedMergeTree.cpp:2349: DB::StorageReplicatedMergeTree::executeLogEntry(DB::ReplicatedMergeTreeLogEntry&) @ 0x0000000015eba91b 20. /build/src/Storages/StorageReplicatedMergeTree.cpp:3876: bool std::__function::__policy_invoker&)>::__call_impl[abi:se190107])::$_1, bool (std::shared_ptr&)>>(std::__function::__policy_storage const*, std::shared_ptr&) @ 0x0000000015f9837e 21. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000165d6fc3 22. /build/src/Storages/StorageReplicatedMergeTree.cpp:3872: DB::StorageReplicatedMergeTree::processQueueEntry(std::shared_ptr) @ 0x0000000015efc18a 23. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001624c1b2 24. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000162f9c70 25. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x00000000162fa55a 26. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc6653 27. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000000fccc4c3 28. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc3d92 29. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fcca080 30. ? @ 0x00007fbc6213eac3 31. ? @ 0x00007fbc621d0850 (version 25.3.6.10636.altinitytest (altinity build)) 2025.07.28 11:53:14.922209 [ 17208 ] {d5f02208-2ef8-4717-90c5-294154ea5148} executeQuery: Code: 475. DB::Exception: WITH FILL TO value cannot be less than FROM value for sorting in ascending direction. (INVALID_WITH_FILL_EXPRESSION) (version 25.3.6.10636.altinitytest (altinity build)) (from [::1]:48408) (comment: 00995_order_by_with_fill.sql) (query 17, line 35) (in query: SELECT * FROM fill ORDER BY a WITH FILL FROM 10 TO 1;), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000000a074fcb 4. /build/src/Planner/PlannerSorting.cpp:123: DB::extractSortDescription(std::shared_ptr const&, DB::PlannerContext const&) @ 0x00000000149c9293 5. /build/src/Planner/Planner.cpp:340: DB::Planner::buildPlanForQueryNode() @ 0x000000001497a96b 6. /build/src/Planner/Planner.cpp:1308: DB::Planner::buildQueryPlanIfNeeded() @ 0x000000001497685c 7. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:255: DB::InterpreterSelectQueryAnalyzer::getQueryPlan() @ 0x000000001497476d 8. /build/src/Interpreters/executeQuery.cpp:1405: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88806 9. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 10. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 11. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 12. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 13. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 14. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 15. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 16. ? @ 0x00007fbc6213eac3 17. ? @ 0x00007fbc621d0850 2025.07.28 11:53:14.997418 [ 17208 ] {} TCPHandler: Code: 475. DB::Exception: WITH FILL TO value cannot be less than FROM value for sorting in ascending direction. (INVALID_WITH_FILL_EXPRESSION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000000a074fcb 4. /build/src/Planner/PlannerSorting.cpp:123: DB::extractSortDescription(std::shared_ptr const&, DB::PlannerContext const&) @ 0x00000000149c9293 5. /build/src/Planner/Planner.cpp:340: DB::Planner::buildPlanForQueryNode() @ 0x000000001497a96b 6. /build/src/Planner/Planner.cpp:1308: DB::Planner::buildQueryPlanIfNeeded() @ 0x000000001497685c 7. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:255: DB::InterpreterSelectQueryAnalyzer::getQueryPlan() @ 0x000000001497476d 8. /build/src/Interpreters/executeQuery.cpp:1405: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88806 9. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 10. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 11. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 12. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 13. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 14. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 15. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 16. ? @ 0x00007fbc6213eac3 17. ? @ 0x00007fbc621d0850 2025.07.28 11:53:15.002141 [ 5871 ] {} ExternalDictionariesLoader: Could not load external dictionary 'cc8b1a52-da70-449c-9c23-8d623c5fcc44', next update is scheduled at 2025-07-28 11:53:24: Code: 396. DB::Exception: Limit for result exceeded, max bytes: 1.00 B, current bytes: 36.00 B. (TOO_MANY_ROWS_OR_BYTES), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, char const*&, ReadableSize&&, ReadableSize&&) @ 0x0000000013bd4eeb 4. /build/src/QueryPipeline/SizeLimits.cpp:43: DB::SizeLimits::check(unsigned long, unsigned long, char const*, int, int) const @ 0x0000000013bd48a1 5. /build/src/Processors/Transforms/LimitsCheckingTransform.cpp:45: DB::LimitsCheckingTransform::transform(DB::Chunk&) @ 0x0000000016c1d2fb 6. /build/src/Processors/ISimpleTransform.h:33: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000011a9a453 7. /build/src/Processors/ISimpleTransform.cpp:89: DB::ISimpleTransform::work() @ 0x000000001699fca0 8. /build/src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x00000000169bd00f 9. /build/src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x00000000169b2105 10. /build/src/Processors/Executors/PipelineExecutor.cpp:170: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x00000000169b16a7 11. /build/src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x00000000169c081c 12. /build/src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x00000000169c0978 13. /build/src/Dictionaries/FlatDictionary.cpp:502: DB::FlatDictionary::loadData() @ 0x0000000011b424cb 14. /build/src/Dictionaries/FlatDictionary.cpp:46: DB::FlatDictionary::FlatDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, DB::FlatDictionary::Configuration, std::shared_ptr) @ 0x0000000011b42111 15. /build/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:se190107]> (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) @ 0x0000000011b5d3e2 16. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000012d8a61d 17. /build/src/Interpreters/ExternalDictionariesLoader.cpp:47: DB::ExternalDictionariesLoader::createObject(String const&, Poco::Util::AbstractConfiguration const&, String const&, String const&) const @ 0x00000000148a6f44 18. /build/src/Interpreters/ExternalLoader.cpp:1522: DB::ExternalLoader::LoadingDispatcher::loadSingleObject(String const&, DB::ExternalLoader::ObjectConfig const&, std::shared_ptr) @ 0x00000000148b2ee8 19. /build/src/Interpreters/ExternalLoader.cpp:998: DB::ExternalLoader::LoadingDispatcher::doLoading(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr) @ 0x00000000148b197d 20. /build/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()() @ 0x00000000148b5991 21. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc3d92 22. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fcca080 23. ? @ 0x00007fbc6213eac3 24. ? @ 0x00007fbc621d0850 (version 25.3.6.10636.altinitytest (altinity build)) 2025.07.28 11:53:15.132678 [ 17208 ] {ae732ea1-3d92-4be1-be38-581c5ff44591} executeQuery: Code: 475. DB::Exception: WITH FILL FROM value cannot be less than TO value for sorting in descending direction. (INVALID_WITH_FILL_EXPRESSION) (version 25.3.6.10636.altinitytest (altinity build)) (from [::1]:48408) (comment: 00995_order_by_with_fill.sql) (query 18, line 36) (in query: SELECT * FROM fill ORDER BY a DESC WITH FILL FROM 1 TO 10;), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000000a074fcb 4. /build/src/Planner/PlannerSorting.cpp:140: DB::extractSortDescription(std::shared_ptr const&, DB::PlannerContext const&) @ 0x00000000149c923d 5. /build/src/Planner/Planner.cpp:340: DB::Planner::buildPlanForQueryNode() @ 0x000000001497a96b 6. /build/src/Planner/Planner.cpp:1308: DB::Planner::buildQueryPlanIfNeeded() @ 0x000000001497685c 7. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:255: DB::InterpreterSelectQueryAnalyzer::getQueryPlan() @ 0x000000001497476d 8. /build/src/Interpreters/executeQuery.cpp:1405: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88806 9. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 10. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 11. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 12. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 13. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 14. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 15. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 16. ? @ 0x00007fbc6213eac3 17. ? @ 0x00007fbc621d0850 2025.07.28 11:53:15.138022 [ 17208 ] {} TCPHandler: Code: 475. DB::Exception: WITH FILL FROM value cannot be less than TO value for sorting in descending direction. (INVALID_WITH_FILL_EXPRESSION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000000a074fcb 4. /build/src/Planner/PlannerSorting.cpp:140: DB::extractSortDescription(std::shared_ptr const&, DB::PlannerContext const&) @ 0x00000000149c923d 5. /build/src/Planner/Planner.cpp:340: DB::Planner::buildPlanForQueryNode() @ 0x000000001497a96b 6. /build/src/Planner/Planner.cpp:1308: DB::Planner::buildQueryPlanIfNeeded() @ 0x000000001497685c 7. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:255: DB::InterpreterSelectQueryAnalyzer::getQueryPlan() @ 0x000000001497476d 8. /build/src/Interpreters/executeQuery.cpp:1405: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88806 9. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 10. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 11. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 12. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 13. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 14. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 15. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 16. ? @ 0x00007fbc6213eac3 17. ? @ 0x00007fbc621d0850 2025.07.28 11:53:15.360705 [ 17208 ] {c543cc90-b3da-493c-8cfa-3af99a57d38e} executeQuery: Code: 475. DB::Exception: WITH FILL bound values cannot be negative for unsigned type UInt32. (INVALID_WITH_FILL_EXPRESSION) (version 25.3.6.10636.altinitytest (altinity build)) (from [::1]:48408) (comment: 00995_order_by_with_fill.sql) (query 19, line 37) (in query: SELECT * FROM fill ORDER BY a WITH FILL FROM -10 to 10;), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x000000000a06b56b 4. /build/src/Processors/Transforms/FillingTransform.cpp:268: DB::FillingTransform::FillingTransform(DB::Block const&, DB::SortDescription const&, DB::SortDescription const&, std::shared_ptr, bool) @ 0x0000000016dbf748 5. /build/contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: std::shared_ptr std::__function::__policy_invoker (DB::Block const&, DB::Pipe::StreamType)>::__call_impl[abi:se190107] (DB::Block const&, DB::Pipe::StreamType)>>(std::__function::__policy_storage const*, DB::Block const&, DB::Pipe::StreamType) @ 0x0000000016dbb21f 6. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000013b9418e 7. /build/src/QueryPipeline/Pipe.cpp:632: DB::Pipe::addSimpleTransform(std::function (DB::Block const&, DB::Pipe::StreamType)> const&) @ 0x0000000013b93f5d 8. /build/src/Processors/QueryPlan/FillingStep.cpp:50: DB::FillingStep::transformPipeline(DB::QueryPipelineBuilder&, DB::BuildQueryPipelineSettings const&) @ 0x0000000016dba7c8 9. /build/src/Processors/QueryPlan/ITransformingStep.cpp:21: DB::ITransformingStep::updatePipeline(std::vector>, std::allocator>>>, DB::BuildQueryPipelineSettings const&) @ 0x0000000016dd1ba5 10. /build/src/Processors/QueryPlan/QueryPlan.cpp:201: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x0000000016e0076f 11. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:275: DB::InterpreterSelectQueryAnalyzer::buildQueryPipeline() @ 0x0000000014974614 12. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:242: DB::InterpreterSelectQueryAnalyzer::execute() @ 0x000000001497439e 13. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88dc9 14. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 15. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 16. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 17. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 18. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 19. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 20. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 21. ? @ 0x00007fbc6213eac3 22. ? @ 0x00007fbc621d0850 2025.07.28 11:53:15.390482 [ 17208 ] {} TCPHandler: Code: 475. DB::Exception: WITH FILL bound values cannot be negative for unsigned type UInt32. (INVALID_WITH_FILL_EXPRESSION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x000000000a06b56b 4. /build/src/Processors/Transforms/FillingTransform.cpp:268: DB::FillingTransform::FillingTransform(DB::Block const&, DB::SortDescription const&, DB::SortDescription const&, std::shared_ptr, bool) @ 0x0000000016dbf748 5. /build/contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: std::shared_ptr std::__function::__policy_invoker (DB::Block const&, DB::Pipe::StreamType)>::__call_impl[abi:se190107] (DB::Block const&, DB::Pipe::StreamType)>>(std::__function::__policy_storage const*, DB::Block const&, DB::Pipe::StreamType) @ 0x0000000016dbb21f 6. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000013b9418e 7. /build/src/QueryPipeline/Pipe.cpp:632: DB::Pipe::addSimpleTransform(std::function (DB::Block const&, DB::Pipe::StreamType)> const&) @ 0x0000000013b93f5d 8. /build/src/Processors/QueryPlan/FillingStep.cpp:50: DB::FillingStep::transformPipeline(DB::QueryPipelineBuilder&, DB::BuildQueryPipelineSettings const&) @ 0x0000000016dba7c8 9. /build/src/Processors/QueryPlan/ITransformingStep.cpp:21: DB::ITransformingStep::updatePipeline(std::vector>, std::allocator>>>, DB::BuildQueryPipelineSettings const&) @ 0x0000000016dd1ba5 10. /build/src/Processors/QueryPlan/QueryPlan.cpp:201: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x0000000016e0076f 11. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:275: DB::InterpreterSelectQueryAnalyzer::buildQueryPipeline() @ 0x0000000014974614 12. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:242: DB::InterpreterSelectQueryAnalyzer::execute() @ 0x000000001497439e 13. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88dc9 14. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 15. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 16. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 17. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 18. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 19. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 20. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 21. ? @ 0x00007fbc6213eac3 22. ? @ 0x00007fbc621d0850 2025.07.28 11:53:15.898575 [ 3966 ] {} test_13.rmt2 (7f9b740d-015c-470e-8cc6-8ba33be0dc63): auto DB::StorageReplicatedMergeTree::processQueueEntry(ReplicatedMergeTreeQueue::SelectedEntryPtr)::(anonymous class)::operator()(LogEntryPtr &) const: Code: 86. DB::HTTPException: Received error from remote server http://146b4357c08d:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Ftest%2F01165%2Ftest_13%2Frmt%2Freplicas%2F1&part=20250728_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.6.10636.altinitytest (altinity build)) '. (RECEIVED_ERROR_FROM_REMOTE_IO_SERVER), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.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 const&, int&&, String const&, unsigned long&&, String const&) @ 0x000000000feda8d9 4. /build/src/IO/HTTPCommon.cpp:104: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x000000000feda6e2 5. /build/src/IO/HTTPCommon.cpp:93: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x000000000feda537 6. /build/src/IO/ReadWriteBufferFromHTTP.cpp:277: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x000000001184a4c4 7. /build/src/IO/ReadWriteBufferFromHTTP.cpp:285: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x000000001184a615 8. /build/src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x000000001184ae59 9. /build/src/IO/ReadWriteBufferFromHTTP.cpp:472: void std::__function::__policy_invoker::__call_impl[abi:se190107]>(std::__function::__policy_storage const*) @ 0x000000001184cedd 10. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001184858b 11. /build/src/IO/ReadWriteBufferFromHTTP.cpp:465: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x000000001184bf0b 12. /build/src/IO/ReadBuffer.h:60: DB::ReadBuffer::next() @ 0x000000000a148c7b 13. /build/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) @ 0x0000000011849fb2 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]>&)>&, 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&) @ 0x0000000011841980 15. /build/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) @ 0x000000001621208e 16. /build/src/Storages/StorageReplicatedMergeTree.cpp:5228: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl[abi:se190107] const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000015f9a5fe 17. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000015ed8bfd 18. /build/src/Storages/StorageReplicatedMergeTree.cpp:2514: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x0000000015ec9aab 19. /build/src/Storages/StorageReplicatedMergeTree.cpp:2349: DB::StorageReplicatedMergeTree::executeLogEntry(DB::ReplicatedMergeTreeLogEntry&) @ 0x0000000015eba91b 20. /build/src/Storages/StorageReplicatedMergeTree.cpp:3876: bool std::__function::__policy_invoker&)>::__call_impl[abi:se190107])::$_1, bool (std::shared_ptr&)>>(std::__function::__policy_storage const*, std::shared_ptr&) @ 0x0000000015f9837e 21. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000165d6fc3 22. /build/src/Storages/StorageReplicatedMergeTree.cpp:3872: DB::StorageReplicatedMergeTree::processQueueEntry(std::shared_ptr) @ 0x0000000015efc18a 23. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001624c1b2 24. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000162f9c70 25. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x00000000162fa55a 26. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc6653 27. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000000fccc4c3 28. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc3d92 29. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fcca080 30. ? @ 0x00007fbc6213eac3 31. ? @ 0x00007fbc621d0850 (version 25.3.6.10636.altinitytest (altinity build)) 2025.07.28 11:53:16.463146 [ 17207 ] {16b30587-7249-4988-9bd3-e09ab6d9846a} executeQuery: Code: 675. DB::Exception: Cannot parse IPv4 test: Cannot parse IPv4 from String: In scope SELECT toIPv4('test'). (CANNOT_PARSE_IPV4) (version 25.3.6.10636.altinitytest (altinity build)) (from [::1]:48582) (comment: 02234_cast_to_ip_address.sql) (query 9, line 13) (in query: SELECT toIPv4('test');), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl>>::type>, std::basic_string_view>&&) @ 0x000000000a119c0b 4. /build/src/IO/ReadHelpers.h:971: COW::immutable_ptr DB::detail::ConvertThroughParsing::execute(std::vector> const&, std::shared_ptr const&, unsigned long, void*) @ 0x00000000130d7d72 5. /build/src/Functions/FunctionsConversion.h:1580: COW::immutable_ptr DB::detail::ConvertImpl::execute(std::vector> const&, std::shared_ptr const&, unsigned long, DB::detail::BehaviourOnErrorFromString, void*) @ 0x00000000130d799e 6. /build/src/Functions/FunctionsConversion.h:2472: 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&&) @ 0x0000000012faabc4 7. /build/src/Functions/FunctionsConversion.h:2527: DB::detail::FunctionConvert>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000012fc8b14 8. /build/src/Functions/FunctionsConversion.h:2307: DB::detail::FunctionConvert>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000012fc82da 9. /build/src/Functions/IFunction.h:437: DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000a069f2a 10. /build/src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000012d9965a 11. /build/src/Functions/IFunction.cpp:351: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d93b02 12. /build/src/Functions/IFunction.cpp:177: DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d93698 13. /build/src/Functions/IFunction.cpp:343: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d93aad 14. /build/src/Functions/IFunction.cpp:420: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d95059 15. /build/src/Functions/IFunction.cpp:498: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d95c72 16. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3567: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000014034494 17. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3838: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000014019a9e 18. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3980: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000014018e31 19. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:4304: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000014042fa7 20. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5605: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000014013749 21. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000140127f9 22. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000014011fce 23. /build/src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000001406ce8a 24. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000014973b42 25. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000001497268d 26. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000014974d24 27. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001492924b 28. /build/src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88641 29. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 30. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 31. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 2025.07.28 11:53:16.485069 [ 17207 ] {} TCPHandler: Code: 675. DB::Exception: Cannot parse IPv4 test: Cannot parse IPv4 from String: In scope SELECT toIPv4('test'). (CANNOT_PARSE_IPV4), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl>>::type>, std::basic_string_view>&&) @ 0x000000000a119c0b 4. /build/src/IO/ReadHelpers.h:971: COW::immutable_ptr DB::detail::ConvertThroughParsing::execute(std::vector> const&, std::shared_ptr const&, unsigned long, void*) @ 0x00000000130d7d72 5. /build/src/Functions/FunctionsConversion.h:1580: COW::immutable_ptr DB::detail::ConvertImpl::execute(std::vector> const&, std::shared_ptr const&, unsigned long, DB::detail::BehaviourOnErrorFromString, void*) @ 0x00000000130d799e 6. /build/src/Functions/FunctionsConversion.h:2472: 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&&) @ 0x0000000012faabc4 7. /build/src/Functions/FunctionsConversion.h:2527: DB::detail::FunctionConvert>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000012fc8b14 8. /build/src/Functions/FunctionsConversion.h:2307: DB::detail::FunctionConvert>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000012fc82da 9. /build/src/Functions/IFunction.h:437: DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000a069f2a 10. /build/src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000012d9965a 11. /build/src/Functions/IFunction.cpp:351: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d93b02 12. /build/src/Functions/IFunction.cpp:177: DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d93698 13. /build/src/Functions/IFunction.cpp:343: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d93aad 14. /build/src/Functions/IFunction.cpp:420: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d95059 15. /build/src/Functions/IFunction.cpp:498: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d95c72 16. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3567: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000014034494 17. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3838: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000014019a9e 18. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3980: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000014018e31 19. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:4304: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000014042fa7 20. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5605: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000014013749 21. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000140127f9 22. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000014011fce 23. /build/src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000001406ce8a 24. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000014973b42 25. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000001497268d 26. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000014974d24 27. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001492924b 28. /build/src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88641 29. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 30. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 31. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 2025.07.28 11:53:16.643666 [ 3285 ] {6562a7ac-66a0-41fa-8dcb-6b3c9a7919e1} executeQuery: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=826, jobs=800). (CANNOT_SCHEDULE_TASK) (version 25.3.6.10636.altinitytest (altinity build)) (from [::1]:48378) (comment: 02009_decimal_no_trailing_zeros.sql) (query 31, line 37) (in query: SELECT 1.123456789012345678901::Decimal256(22);), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000fccaeeb 4. /build/src/Common/ThreadPool.cpp:275: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000fccacb3 5. /build/src/Common/ThreadPool.cpp:323: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fcc4ffc 6. /build/src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000000fcc584d 7. /build/src/Common/ThreadPool.h:279: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x00000000169bf193 8. /build/src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x00000000169bf518 9. /build/src/Server/TCPHandler.cpp:1237: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x00000000168f1525 10. /build/src/Server/TCPHandler.cpp:678: DB::TCPHandler::runImpl() @ 0x00000000168e68e5 11. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 12. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 13. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 14. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 15. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 16. ? @ 0x00007fbc6213eac3 17. ? @ 0x00007fbc621d0850 2025.07.28 11:53:16.662695 [ 3285 ] {} TCPHandler: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=826, jobs=800). (CANNOT_SCHEDULE_TASK), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000fccaeeb 4. /build/src/Common/ThreadPool.cpp:275: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000fccacb3 5. /build/src/Common/ThreadPool.cpp:323: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fcc4ffc 6. /build/src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000000fcc584d 7. /build/src/Common/ThreadPool.h:279: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x00000000169bf193 8. /build/src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x00000000169bf518 9. /build/src/Server/TCPHandler.cpp:1237: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x00000000168f1525 10. /build/src/Server/TCPHandler.cpp:678: DB::TCPHandler::runImpl() @ 0x00000000168e68e5 11. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 12. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 13. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 14. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 15. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 16. ? @ 0x00007fbc6213eac3 17. ? @ 0x00007fbc621d0850 2025.07.28 11:53:16.746645 [ 3976 ] {} test_13.rmt2 (7f9b740d-015c-470e-8cc6-8ba33be0dc63): auto DB::StorageReplicatedMergeTree::processQueueEntry(ReplicatedMergeTreeQueue::SelectedEntryPtr)::(anonymous class)::operator()(LogEntryPtr &) const: Code: 86. DB::HTTPException: Received error from remote server http://146b4357c08d:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Ftest%2F01165%2Ftest_13%2Frmt%2Freplicas%2F1&part=20250728_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.6.10636.altinitytest (altinity build)) '. (RECEIVED_ERROR_FROM_REMOTE_IO_SERVER), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.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 const&, int&&, String const&, unsigned long&&, String const&) @ 0x000000000feda8d9 4. /build/src/IO/HTTPCommon.cpp:104: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x000000000feda6e2 5. /build/src/IO/HTTPCommon.cpp:93: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x000000000feda537 6. /build/src/IO/ReadWriteBufferFromHTTP.cpp:277: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x000000001184a4c4 7. /build/src/IO/ReadWriteBufferFromHTTP.cpp:285: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x000000001184a615 8. /build/src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x000000001184ae59 9. /build/src/IO/ReadWriteBufferFromHTTP.cpp:472: void std::__function::__policy_invoker::__call_impl[abi:se190107]>(std::__function::__policy_storage const*) @ 0x000000001184cedd 10. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001184858b 11. /build/src/IO/ReadWriteBufferFromHTTP.cpp:465: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x000000001184bf0b 12. /build/src/IO/ReadBuffer.h:60: DB::ReadBuffer::next() @ 0x000000000a148c7b 13. /build/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) @ 0x0000000011849fb2 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]>&)>&, 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&) @ 0x0000000011841980 15. /build/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) @ 0x000000001621208e 16. /build/src/Storages/StorageReplicatedMergeTree.cpp:5228: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl[abi:se190107] const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000015f9a5fe 17. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000015ed8bfd 18. /build/src/Storages/StorageReplicatedMergeTree.cpp:2514: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x0000000015ec9aab 19. /build/src/Storages/StorageReplicatedMergeTree.cpp:2349: DB::StorageReplicatedMergeTree::executeLogEntry(DB::ReplicatedMergeTreeLogEntry&) @ 0x0000000015eba91b 20. /build/src/Storages/StorageReplicatedMergeTree.cpp:3876: bool std::__function::__policy_invoker&)>::__call_impl[abi:se190107])::$_1, bool (std::shared_ptr&)>>(std::__function::__policy_storage const*, std::shared_ptr&) @ 0x0000000015f9837e 21. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000165d6fc3 22. /build/src/Storages/StorageReplicatedMergeTree.cpp:3872: DB::StorageReplicatedMergeTree::processQueueEntry(std::shared_ptr) @ 0x0000000015efc18a 23. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001624c1b2 24. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000162f9c70 25. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x00000000162fa55a 26. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc6653 27. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000000fccc4c3 28. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc3d92 29. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fcca080 30. ? @ 0x00007fbc6213eac3 31. ? @ 0x00007fbc621d0850 (version 25.3.6.10636.altinitytest (altinity build)) 2025.07.28 11:53:17.233523 [ 17203 ] {fded77ca-27f1-4ffd-94dd-4021c823278d} executeQuery: Code: 57. DB::Exception: Table test_7.dict_data already exists. (TABLE_ALREADY_EXISTS) (version 25.3.6.10636.altinitytest (altinity build)) (from [::1]:48734) (comment: 01254_dict_create_without_db.sql) (query 1, line 1) (in query: CREATE TABLE dict_data (key UInt64, val UInt64) Engine=Memory();), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000a06a8eb 4. /build/src/Interpreters/InterpreterCreateQuery.cpp:1824: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x0000000014901d53 5. /build/src/Interpreters/InterpreterCreateQuery.cpp:1743: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000148f9aa9 6. /build/src/Interpreters/InterpreterCreateQuery.cpp:2352: DB::InterpreterCreateQuery::execute() @ 0x0000000014905a41 7. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88dc9 8. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 9. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 10. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 11. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 12. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 13. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 14. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 15. ? @ 0x00007fbc6213eac3 16. ? @ 0x00007fbc621d0850 2025.07.28 11:53:17.262688 [ 17203 ] {} TCPHandler: Code: 57. DB::Exception: Table test_7.dict_data already exists. (TABLE_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000a06a8eb 4. /build/src/Interpreters/InterpreterCreateQuery.cpp:1824: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x0000000014901d53 5. /build/src/Interpreters/InterpreterCreateQuery.cpp:1743: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000148f9aa9 6. /build/src/Interpreters/InterpreterCreateQuery.cpp:2352: DB::InterpreterCreateQuery::execute() @ 0x0000000014905a41 7. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88dc9 8. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 9. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 10. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 11. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 12. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 13. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 14. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 15. ? @ 0x00007fbc6213eac3 16. ? @ 0x00007fbc621d0850 2025.07.28 11:53:17.356093 [ 17306 ] {b58c6442-9350-4b94-8b83-ec15d94a5011} DynamicQueryHandler: Code: 36. DB::Exception: The values of the `additional_http_headers` cannot contain ASCII control characters. (BAD_ARGUMENTS), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000000a074fcb 4. /build/src/Interpreters/executeQuery.cpp:1801: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x0000000014c8db9e 5. /build/src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000001686da12 6. /build/src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x0000000016870807 7. /build/src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x0000000016907e99 8. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 9. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 10. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 11. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 12. ? @ 0x00007fbc6213eac3 13. ? @ 0x00007fbc621d0850 (version 25.3.6.10636.altinitytest (altinity build)) 2025.07.28 11:53:17.523921 [ 17203 ] {104d4420-1704-46c4-9c86-ac51af412a0e} DynamicQueryHandler: Code: 36. DB::Exception: The values of the `additional_http_headers` cannot contain ASCII control characters. (BAD_ARGUMENTS), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000000a074fcb 4. /build/src/Interpreters/executeQuery.cpp:1801: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x0000000014c8db9e 5. /build/src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000001686da12 6. /build/src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x0000000016870807 7. /build/src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x0000000016907e99 8. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 9. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 10. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 11. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 12. ? @ 0x00007fbc6213eac3 13. ? @ 0x00007fbc621d0850 (version 25.3.6.10636.altinitytest (altinity build)) 2025.07.28 11:53:17.665091 [ 17321 ] {b394671d-a2e3-48de-9952-400b9fff1549} DynamicQueryHandler: Code: 36. DB::Exception: There are duplicate entries in the `additional_http_headers` setting. (BAD_ARGUMENTS), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000000a074fcb 4. /build/src/Interpreters/executeQuery.cpp:1804: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x0000000014c8dcff 5. /build/src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000001686da12 6. /build/src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x0000000016870807 7. /build/src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x0000000016907e99 8. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 9. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 10. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 11. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 12. ? @ 0x00007fbc6213eac3 13. ? @ 0x00007fbc621d0850 (version 25.3.6.10636.altinitytest (altinity build)) 2025.07.28 11:53:17.699464 [ 3971 ] {} test_13.rmt2 (7f9b740d-015c-470e-8cc6-8ba33be0dc63): auto DB::StorageReplicatedMergeTree::processQueueEntry(ReplicatedMergeTreeQueue::SelectedEntryPtr)::(anonymous class)::operator()(LogEntryPtr &) const: Code: 86. DB::HTTPException: Received error from remote server http://146b4357c08d:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Ftest%2F01165%2Ftest_13%2Frmt%2Freplicas%2F1&part=20250728_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.6.10636.altinitytest (altinity build)) '. (RECEIVED_ERROR_FROM_REMOTE_IO_SERVER), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.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 const&, int&&, String const&, unsigned long&&, String const&) @ 0x000000000feda8d9 4. /build/src/IO/HTTPCommon.cpp:104: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x000000000feda6e2 5. /build/src/IO/HTTPCommon.cpp:93: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x000000000feda537 6. /build/src/IO/ReadWriteBufferFromHTTP.cpp:277: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x000000001184a4c4 7. /build/src/IO/ReadWriteBufferFromHTTP.cpp:285: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x000000001184a615 8. /build/src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x000000001184ae59 9. /build/src/IO/ReadWriteBufferFromHTTP.cpp:472: void std::__function::__policy_invoker::__call_impl[abi:se190107]>(std::__function::__policy_storage const*) @ 0x000000001184cedd 10. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001184858b 11. /build/src/IO/ReadWriteBufferFromHTTP.cpp:465: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x000000001184bf0b 12. /build/src/IO/ReadBuffer.h:60: DB::ReadBuffer::next() @ 0x000000000a148c7b 13. /build/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) @ 0x0000000011849fb2 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]>&)>&, 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&) @ 0x0000000011841980 15. /build/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) @ 0x000000001621208e 16. /build/src/Storages/StorageReplicatedMergeTree.cpp:5228: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl[abi:se190107] const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000015f9a5fe 17. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000015ed8bfd 18. /build/src/Storages/StorageReplicatedMergeTree.cpp:2514: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x0000000015ec9aab 19. /build/src/Storages/StorageReplicatedMergeTree.cpp:2349: DB::StorageReplicatedMergeTree::executeLogEntry(DB::ReplicatedMergeTreeLogEntry&) @ 0x0000000015eba91b 20. /build/src/Storages/StorageReplicatedMergeTree.cpp:3876: bool std::__function::__policy_invoker&)>::__call_impl[abi:se190107])::$_1, bool (std::shared_ptr&)>>(std::__function::__policy_storage const*, std::shared_ptr&) @ 0x0000000015f9837e 21. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000165d6fc3 22. /build/src/Storages/StorageReplicatedMergeTree.cpp:3872: DB::StorageReplicatedMergeTree::processQueueEntry(std::shared_ptr) @ 0x0000000015efc18a 23. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001624c1b2 24. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000162f9c70 25. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x00000000162fa55a 26. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc6653 27. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000000fccc4c3 28. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc3d92 29. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fcca080 30. ? @ 0x00007fbc6213eac3 31. ? @ 0x00007fbc621d0850 (version 25.3.6.10636.altinitytest (altinity build)) 2025.07.28 11:53:17.722628 [ 17207 ] {82bbf0c4-97bf-42e5-a080-f6b9fd609746} executeQuery: Code: 70. DB::Exception: IPv6 ::afff:102:304 in column IPv6 is not in IPv4 mapping block: In scope SELECT toIPv4(toIPv6('::afff:1.2.3.4')). (CANNOT_CONVERT_TYPE) (version 25.3.6.10636.altinitytest (altinity build)) (from [::1]:48582) (comment: 02234_cast_to_ip_address.sql) (query 17, line 24) (in query: SELECT toIPv4(toIPv6('::afff:1.2.3.4'));), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, char (&) [46], String&&) @ 0x0000000012dfe36b 4. /build/src/Functions/FunctionsConversion.h:1779: COW::immutable_ptr DB::detail::ConvertImpl::execute(std::vector> const&, std::shared_ptr const&, unsigned long, DB::detail::BehaviourOnErrorFromString, void*) @ 0x00000000130daba6 5. /build/src/Functions/FunctionsConversion.h:2472: 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&&) @ 0x0000000012faafc4 6. /build/src/Functions/FunctionsConversion.h:2527: DB::detail::FunctionConvert>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000012fc8b14 7. /build/src/Functions/FunctionsConversion.h:2307: DB::detail::FunctionConvert>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000012fc82da 8. /build/src/Functions/IFunction.h:437: DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000a069f2a 9. /build/src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000012d9965a 10. /build/src/Functions/IFunction.cpp:351: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d93b02 11. /build/src/Functions/IFunction.cpp:177: DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d93698 12. /build/src/Functions/IFunction.cpp:343: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d93aad 13. /build/src/Functions/IFunction.cpp:420: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d95059 14. /build/src/Functions/IFunction.cpp:498: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d95c72 15. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3567: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000014034494 16. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3838: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000014019a9e 17. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3980: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000014018e31 18. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:4304: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000014042fa7 19. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5605: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000014013749 20. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000140127f9 21. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000014011fce 22. /build/src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000001406ce8a 23. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000014973b42 24. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000001497268d 25. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000014974d24 26. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001492924b 27. /build/src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88641 28. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 29. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 30. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 31. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 2025.07.28 11:53:17.730230 [ 17207 ] {} TCPHandler: Code: 70. DB::Exception: IPv6 ::afff:102:304 in column IPv6 is not in IPv4 mapping block: In scope SELECT toIPv4(toIPv6('::afff:1.2.3.4')). (CANNOT_CONVERT_TYPE), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, char (&) [46], String&&) @ 0x0000000012dfe36b 4. /build/src/Functions/FunctionsConversion.h:1779: COW::immutable_ptr DB::detail::ConvertImpl::execute(std::vector> const&, std::shared_ptr const&, unsigned long, DB::detail::BehaviourOnErrorFromString, void*) @ 0x00000000130daba6 5. /build/src/Functions/FunctionsConversion.h:2472: 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&&) @ 0x0000000012faafc4 6. /build/src/Functions/FunctionsConversion.h:2527: DB::detail::FunctionConvert>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000012fc8b14 7. /build/src/Functions/FunctionsConversion.h:2307: DB::detail::FunctionConvert>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000012fc82da 8. /build/src/Functions/IFunction.h:437: DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000a069f2a 9. /build/src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000012d9965a 10. /build/src/Functions/IFunction.cpp:351: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d93b02 11. /build/src/Functions/IFunction.cpp:177: DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d93698 12. /build/src/Functions/IFunction.cpp:343: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d93aad 13. /build/src/Functions/IFunction.cpp:420: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d95059 14. /build/src/Functions/IFunction.cpp:498: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d95c72 15. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3567: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000014034494 16. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3838: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000014019a9e 17. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3980: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000014018e31 18. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:4304: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000014042fa7 19. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5605: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000014013749 20. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000140127f9 21. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000014011fce 22. /build/src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000001406ce8a 23. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000014973b42 24. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000001497268d 25. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000014974d24 26. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001492924b 27. /build/src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88641 28. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 29. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 30. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 31. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 2025.07.28 11:53:18.371720 [ 17243 ] {3b3ed857-9ff7-430d-8b0c-71b655e248f1} executeQuery: Code: 264. DB::Exception: Table test_bef8j6qm.t2 (528485de-b7af-4d7c-ba03-297066b0f234) needs the same join_use_nulls setting as present in LEFT or FULL JOIN. (INCOMPATIBLE_TYPE_OF_JOIN) (version 25.3.6.10636.altinitytest (altinity build)) (from [::1]:48746) (comment: 00119_storage_join.sql) (query 6, line 9) (in query: SELECT k, s FROM (SELECT number AS k FROM system.numbers LIMIT 10) js1 ANY LEFT JOIN t2 USING k;), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x000000000a06b56b 4. /build/src/Storages/StorageJoin.cpp:248: DB::StorageJoin::getJoinLocked(std::shared_ptr, String, std::chrono::duration>, std::vector> const&) const @ 0x0000000015dc39bc 5. /build/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) @ 0x00000000149c52b9 6. /build/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) @ 0x0000000016de9821 7. /build/src/Processors/QueryPlan/Optimizations/optimizeJoin.cpp:251: DB::QueryPlanOptimizations::convertLogicalJoinToPhysical(DB::QueryPlan::Node&, std::list>&, DB::QueryPlanOptimizationSettings const&, std::optional) @ 0x0000000016eb5ce9 8. /build/src/Processors/QueryPlan/Optimizations/optimizeTree.cpp:158: DB::QueryPlanOptimizations::optimizeTreeSecondPass(DB::QueryPlanOptimizationSettings const&, DB::QueryPlan::Node&, std::list>&) @ 0x0000000016ead357 9. /build/src/Processors/QueryPlan/QueryPlan.cpp:487: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x0000000016e0055c 10. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:275: DB::InterpreterSelectQueryAnalyzer::buildQueryPipeline() @ 0x0000000014974614 11. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:242: DB::InterpreterSelectQueryAnalyzer::execute() @ 0x000000001497439e 12. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88dc9 13. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 14. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 15. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 16. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 17. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 18. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 19. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 20. ? @ 0x00007fbc6213eac3 21. ? @ 0x00007fbc621d0850 2025.07.28 11:53:18.419714 [ 17243 ] {} TCPHandler: Code: 264. DB::Exception: Table test_bef8j6qm.t2 (528485de-b7af-4d7c-ba03-297066b0f234) 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. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x000000000a06b56b 4. /build/src/Storages/StorageJoin.cpp:248: DB::StorageJoin::getJoinLocked(std::shared_ptr, String, std::chrono::duration>, std::vector> const&) const @ 0x0000000015dc39bc 5. /build/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) @ 0x00000000149c52b9 6. /build/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) @ 0x0000000016de9821 7. /build/src/Processors/QueryPlan/Optimizations/optimizeJoin.cpp:251: DB::QueryPlanOptimizations::convertLogicalJoinToPhysical(DB::QueryPlan::Node&, std::list>&, DB::QueryPlanOptimizationSettings const&, std::optional) @ 0x0000000016eb5ce9 8. /build/src/Processors/QueryPlan/Optimizations/optimizeTree.cpp:158: DB::QueryPlanOptimizations::optimizeTreeSecondPass(DB::QueryPlanOptimizationSettings const&, DB::QueryPlan::Node&, std::list>&) @ 0x0000000016ead357 9. /build/src/Processors/QueryPlan/QueryPlan.cpp:487: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x0000000016e0055c 10. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:275: DB::InterpreterSelectQueryAnalyzer::buildQueryPipeline() @ 0x0000000014974614 11. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:242: DB::InterpreterSelectQueryAnalyzer::execute() @ 0x000000001497439e 12. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88dc9 13. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 14. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 15. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 16. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 17. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 18. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 19. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 20. ? @ 0x00007fbc6213eac3 21. ? @ 0x00007fbc621d0850 2025.07.28 11:53:18.432959 [ 5112 ] {9ea73031-1cfc-44ff-861c-4155c6c459fb} executeQuery: Code: 69. DB::Exception: Scale 36 is out of bounds (max scale: 18): In scope SELECT e + e, e - e, e * e, e / e, intDiv(e, e), intDivOrZero(e, e) FROM decimal WHERE e > 0. (ARGUMENT_OUT_OF_BOUND) (version 25.3.6.10636.altinitytest (altinity build)) (from [::1]:48688) (comment: 00700_decimal_arithm.sql) (query 9, line 29) (in query: SELECT e + e, e - e, e * e, e / e, intDiv(e, e), intDivOrZero(e, e) FROM decimal WHERE e > 0;), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, unsigned long&&) @ 0x000000000a06f86b 4. /build/src/DataTypes/DataTypeDecimalBase.h:77: DB::DataTypeDecimalBase>::DataTypeDecimalBase(unsigned int, unsigned int) @ 0x0000000013bddbe5 5. /build/src/DataTypes/DataTypesDecimal.h:39: auto auto bool DB::FunctionBinaryArithmetic::castBothTypes::getReturnTypeImplStatic(std::vector, std::allocator>> const&, std::shared_ptr)::'lambda'(auto const&, auto const&)>(DB::IDataType const*, DB::IDataType const*, auto&&)::'lambda'(auto const&)::operator()>>(auto const&) const::'lambda'(auto const&)::operator()>>(auto const&) const @ 0x000000000dae83c1 6. /build/src/Functions/castTypeToEither.h:18: bool DB::FunctionBinaryArithmetic::castType::castBothTypes::getReturnTypeImplStatic(std::vector, std::allocator>> const&, std::shared_ptr)::'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&&) @ 0x000000000dae8050 7. /build/src/Functions/FunctionBinaryArithmetic.h:846: bool DB::FunctionBinaryArithmetic::castType::castBothTypes::getReturnTypeImplStatic(std::vector, std::allocator>> const&, std::shared_ptr)::'lambda'(auto const&, auto const&)>(DB::IDataType const*, DB::IDataType const*, auto&&)::'lambda'(auto const&)>(DB::IDataType const*, auto&&) @ 0x000000000dae0523 8. /build/src/Functions/FunctionBinaryArithmetic.h:844: DB::FunctionBinaryArithmetic::getReturnTypeImplStatic(std::vector, std::allocator>> const&, std::shared_ptr) @ 0x000000000dadf6d2 9. /build/src/Functions/IFunction.h:369: DB::IFunctionOverloadResolver::getReturnTypeImpl(std::vector> const&) const @ 0x000000000a6646de 10. /build/src/Functions/IFunction.cpp:645: DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x0000000012d96b0c 11. /build/src/Functions/IFunction.cpp:577: DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x0000000012d9669c 12. /build/src/Functions/IFunction.cpp:606: DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x0000000012d96edc 13. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3544: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000014033cc9 14. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3838: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000014019a9e 15. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3980: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000014018e31 16. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:4304: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000014042fa7 17. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5605: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000014013749 18. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000140127f9 19. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000014011fce 20. /build/src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000001406ce8a 21. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000014973b42 22. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000001497268d 23. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000014974d24 24. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001492924b 25. /build/src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88641 26. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 27. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 28. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 29. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 30. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 31. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 2025.07.28 11:53:18.451350 [ 5112 ] {} TCPHandler: Code: 69. DB::Exception: Scale 36 is out of bounds (max scale: 18): In scope SELECT e + e, e - e, e * e, e / e, intDiv(e, e), intDivOrZero(e, e) FROM decimal WHERE e > 0. (ARGUMENT_OUT_OF_BOUND), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, unsigned long&&) @ 0x000000000a06f86b 4. /build/src/DataTypes/DataTypeDecimalBase.h:77: DB::DataTypeDecimalBase>::DataTypeDecimalBase(unsigned int, unsigned int) @ 0x0000000013bddbe5 5. /build/src/DataTypes/DataTypesDecimal.h:39: auto auto bool DB::FunctionBinaryArithmetic::castBothTypes::getReturnTypeImplStatic(std::vector, std::allocator>> const&, std::shared_ptr)::'lambda'(auto const&, auto const&)>(DB::IDataType const*, DB::IDataType const*, auto&&)::'lambda'(auto const&)::operator()>>(auto const&) const::'lambda'(auto const&)::operator()>>(auto const&) const @ 0x000000000dae83c1 6. /build/src/Functions/castTypeToEither.h:18: bool DB::FunctionBinaryArithmetic::castType::castBothTypes::getReturnTypeImplStatic(std::vector, std::allocator>> const&, std::shared_ptr)::'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&&) @ 0x000000000dae8050 7. /build/src/Functions/FunctionBinaryArithmetic.h:846: bool DB::FunctionBinaryArithmetic::castType::castBothTypes::getReturnTypeImplStatic(std::vector, std::allocator>> const&, std::shared_ptr)::'lambda'(auto const&, auto const&)>(DB::IDataType const*, DB::IDataType const*, auto&&)::'lambda'(auto const&)>(DB::IDataType const*, auto&&) @ 0x000000000dae0523 8. /build/src/Functions/FunctionBinaryArithmetic.h:844: DB::FunctionBinaryArithmetic::getReturnTypeImplStatic(std::vector, std::allocator>> const&, std::shared_ptr) @ 0x000000000dadf6d2 9. /build/src/Functions/IFunction.h:369: DB::IFunctionOverloadResolver::getReturnTypeImpl(std::vector> const&) const @ 0x000000000a6646de 10. /build/src/Functions/IFunction.cpp:645: DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x0000000012d96b0c 11. /build/src/Functions/IFunction.cpp:577: DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x0000000012d9669c 12. /build/src/Functions/IFunction.cpp:606: DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x0000000012d96edc 13. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3544: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000014033cc9 14. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3838: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000014019a9e 15. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3980: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000014018e31 16. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:4304: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000014042fa7 17. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5605: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000014013749 18. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000140127f9 19. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000014011fce 20. /build/src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000001406ce8a 21. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000014973b42 22. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000001497268d 23. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000014974d24 24. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001492924b 25. /build/src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88641 26. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 27. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 28. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 29. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 30. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 31. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 2025.07.28 11:53:18.484049 [ 17207 ] {1360e920-ab4e-4f15-b95e-b9d9beef06cb} executeQuery: Code: 675. DB::Exception: Invalid IPv4 value: In scope SELECT CAST('test', 'IPv4'). (CANNOT_PARSE_IPV4) (version 25.3.6.10636.altinitytest (altinity build)) (from [::1]:48582) (comment: 02234_cast_to_ip_address.sql) (query 21, line 30) (in query: SELECT cast('test' , 'IPv4');), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000000a074fcb 4. /build/src/Functions/FunctionsCodingIP.h:277: COW::immutable_ptr DB::convertToIPv4<(DB::IPStringToNumExceptionMode)0, DB::ColumnVector>(COW::immutable_ptr, DB::PODArray, 63ul, 64ul> const*) @ 0x0000000012df6ee8 5. /build/src/Functions/FunctionsConversion.h:5991: bool DB::detail::FunctionCast::prepareImpl(std::shared_ptr const&, std::shared_ptr const&, bool) const::'lambda0'(auto const&)::operator()>(auto const&) 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 @ 0x0000000012df5faa 6. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: COW::immutable_ptr std::__function::__policy_invoker::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)>::__call_impl[abi:se190107] const&, std::shared_ptr const&, bool) const::'lambda0'(auto const&)::operator()>(auto 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) @ 0x0000000012df5e69 7. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000012ddcb1b 8. /build/src/Functions/IFunction.h:57: DB::IExecutableFunction::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000a08134a 9. /build/src/Functions/IFunction.cpp:351: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d93b02 10. /build/src/Functions/IFunction.cpp:177: DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d93698 11. /build/src/Functions/IFunction.cpp:343: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d93aad 12. /build/src/Functions/IFunction.cpp:424: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d94e1b 13. /build/src/Functions/IFunction.cpp:498: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d95c72 14. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3567: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000014034494 15. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3838: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000014019a9e 16. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3980: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000014018e31 17. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:4304: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000014042fa7 18. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5605: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000014013749 19. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000140127f9 20. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000014011fce 21. /build/src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000001406ce8a 22. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000014973b42 23. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000001497268d 24. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000014974d24 25. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001492924b 26. /build/src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88641 27. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 28. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 29. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 30. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 31. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 2025.07.28 11:53:18.520863 [ 17207 ] {} TCPHandler: Code: 675. DB::Exception: Invalid IPv4 value: In scope SELECT CAST('test', 'IPv4'). (CANNOT_PARSE_IPV4), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000000a074fcb 4. /build/src/Functions/FunctionsCodingIP.h:277: COW::immutable_ptr DB::convertToIPv4<(DB::IPStringToNumExceptionMode)0, DB::ColumnVector>(COW::immutable_ptr, DB::PODArray, 63ul, 64ul> const*) @ 0x0000000012df6ee8 5. /build/src/Functions/FunctionsConversion.h:5991: bool DB::detail::FunctionCast::prepareImpl(std::shared_ptr const&, std::shared_ptr const&, bool) const::'lambda0'(auto const&)::operator()>(auto const&) 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 @ 0x0000000012df5faa 6. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: COW::immutable_ptr std::__function::__policy_invoker::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)>::__call_impl[abi:se190107] const&, std::shared_ptr const&, bool) const::'lambda0'(auto const&)::operator()>(auto 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) @ 0x0000000012df5e69 7. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000012ddcb1b 8. /build/src/Functions/IFunction.h:57: DB::IExecutableFunction::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000a08134a 9. /build/src/Functions/IFunction.cpp:351: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d93b02 10. /build/src/Functions/IFunction.cpp:177: DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d93698 11. /build/src/Functions/IFunction.cpp:343: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d93aad 12. /build/src/Functions/IFunction.cpp:424: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d94e1b 13. /build/src/Functions/IFunction.cpp:498: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d95c72 14. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3567: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000014034494 15. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3838: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000014019a9e 16. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3980: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000014018e31 17. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:4304: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000014042fa7 18. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5605: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000014013749 19. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000140127f9 20. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000014011fce 21. /build/src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000001406ce8a 22. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000014973b42 23. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000001497268d 24. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000014974d24 25. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001492924b 26. /build/src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88641 27. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 28. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 29. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 30. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 31. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 2025.07.28 11:53:18.802325 [ 3974 ] {} test_13.rmt2 (7f9b740d-015c-470e-8cc6-8ba33be0dc63): auto DB::StorageReplicatedMergeTree::processQueueEntry(ReplicatedMergeTreeQueue::SelectedEntryPtr)::(anonymous class)::operator()(LogEntryPtr &) const: Code: 86. DB::HTTPException: Received error from remote server http://146b4357c08d:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Ftest%2F01165%2Ftest_13%2Frmt%2Freplicas%2F1&part=20250728_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.6.10636.altinitytest (altinity build)) '. (RECEIVED_ERROR_FROM_REMOTE_IO_SERVER), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.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 const&, int&&, String const&, unsigned long&&, String const&) @ 0x000000000feda8d9 4. /build/src/IO/HTTPCommon.cpp:104: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x000000000feda6e2 5. /build/src/IO/HTTPCommon.cpp:93: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x000000000feda537 6. /build/src/IO/ReadWriteBufferFromHTTP.cpp:277: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x000000001184a4c4 7. /build/src/IO/ReadWriteBufferFromHTTP.cpp:285: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x000000001184a615 8. /build/src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x000000001184ae59 9. /build/src/IO/ReadWriteBufferFromHTTP.cpp:472: void std::__function::__policy_invoker::__call_impl[abi:se190107]>(std::__function::__policy_storage const*) @ 0x000000001184cedd 10. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001184858b 11. /build/src/IO/ReadWriteBufferFromHTTP.cpp:465: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x000000001184bf0b 12. /build/src/IO/ReadBuffer.h:60: DB::ReadBuffer::next() @ 0x000000000a148c7b 13. /build/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) @ 0x0000000011849fb2 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]>&)>&, 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&) @ 0x0000000011841980 15. /build/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) @ 0x000000001621208e 16. /build/src/Storages/StorageReplicatedMergeTree.cpp:5228: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl[abi:se190107] const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000015f9a5fe 17. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000015ed8bfd 18. /build/src/Storages/StorageReplicatedMergeTree.cpp:2514: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x0000000015ec9aab 19. /build/src/Storages/StorageReplicatedMergeTree.cpp:2349: DB::StorageReplicatedMergeTree::executeLogEntry(DB::ReplicatedMergeTreeLogEntry&) @ 0x0000000015eba91b 20. /build/src/Storages/StorageReplicatedMergeTree.cpp:3876: bool std::__function::__policy_invoker&)>::__call_impl[abi:se190107])::$_1, bool (std::shared_ptr&)>>(std::__function::__policy_storage const*, std::shared_ptr&) @ 0x0000000015f9837e 21. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000165d6fc3 22. /build/src/Storages/StorageReplicatedMergeTree.cpp:3872: DB::StorageReplicatedMergeTree::processQueueEntry(std::shared_ptr) @ 0x0000000015efc18a 23. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001624c1b2 24. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000162f9c70 25. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x00000000162fa55a 26. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc6653 27. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000000fccc4c3 28. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc3d92 29. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fcca080 30. ? @ 0x00007fbc6213eac3 31. ? @ 0x00007fbc621d0850 (version 25.3.6.10636.altinitytest (altinity build)) 2025.07.28 11:53:18.803396 [ 5112 ] {6a9ea366-a8e2-4aad-8f3d-381551f15cac} executeQuery: Code: 69. DB::Exception: Scale 76 is out of bounds (max scale: 38): In scope SELECT f + f, f - f, f * f, f / f, intDiv(f, f), intDivOrZero(f, f) FROM decimal WHERE f > 0. (ARGUMENT_OUT_OF_BOUND) (version 25.3.6.10636.altinitytest (altinity build)) (from [::1]:48688) (comment: 00700_decimal_arithm.sql) (query 10, line 30) (in query: SELECT f + f, f - f, f * f, f / f, intDiv(f, f), intDivOrZero(f, f) FROM decimal WHERE f > 0;), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, unsigned long&&) @ 0x000000000a06f86b 4. /build/src/DataTypes/DataTypeDecimalBase.h:77: DB::DataTypeDecimalBase>>::DataTypeDecimalBase(unsigned int, unsigned int) @ 0x0000000013bde105 5. /build/src/DataTypes/DataTypesDecimal.h:39: auto auto bool DB::FunctionBinaryArithmetic::castBothTypes::getReturnTypeImplStatic(std::vector, std::allocator>> const&, std::shared_ptr)::'lambda'(auto const&, auto const&)>(DB::IDataType const*, DB::IDataType const*, auto&&)::'lambda'(auto const&)::operator()>>>(auto const&) const::'lambda'(auto const&)::operator()>>>(auto const&) const @ 0x000000000dae8ee1 6. /build/src/Functions/castTypeToEither.h:18: bool DB::FunctionBinaryArithmetic::castType::castBothTypes::getReturnTypeImplStatic(std::vector, std::allocator>> const&, std::shared_ptr)::'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&&) @ 0x000000000dae8b38 7. /build/src/Functions/FunctionBinaryArithmetic.h:846: bool DB::FunctionBinaryArithmetic::castType::castBothTypes::getReturnTypeImplStatic(std::vector, std::allocator>> const&, std::shared_ptr)::'lambda'(auto const&, auto const&)>(DB::IDataType const*, DB::IDataType const*, auto&&)::'lambda'(auto const&)>(DB::IDataType const*, auto&&) @ 0x000000000dae05a3 8. /build/src/Functions/FunctionBinaryArithmetic.h:844: DB::FunctionBinaryArithmetic::getReturnTypeImplStatic(std::vector, std::allocator>> const&, std::shared_ptr) @ 0x000000000dadf6d2 9. /build/src/Functions/IFunction.h:369: DB::IFunctionOverloadResolver::getReturnTypeImpl(std::vector> const&) const @ 0x000000000a6646de 10. /build/src/Functions/IFunction.cpp:645: DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x0000000012d96b0c 11. /build/src/Functions/IFunction.cpp:577: DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x0000000012d9669c 12. /build/src/Functions/IFunction.cpp:606: DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x0000000012d96edc 13. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3544: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000014033cc9 14. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3838: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000014019a9e 15. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3980: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000014018e31 16. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:4304: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000014042fa7 17. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5605: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000014013749 18. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000140127f9 19. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000014011fce 20. /build/src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000001406ce8a 21. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000014973b42 22. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000001497268d 23. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000014974d24 24. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001492924b 25. /build/src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88641 26. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 27. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 28. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 29. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 30. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 31. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 2025.07.28 11:53:18.810178 [ 5112 ] {} TCPHandler: Code: 69. DB::Exception: Scale 76 is out of bounds (max scale: 38): In scope SELECT f + f, f - f, f * f, f / f, intDiv(f, f), intDivOrZero(f, f) FROM decimal WHERE f > 0. (ARGUMENT_OUT_OF_BOUND), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, unsigned long&&) @ 0x000000000a06f86b 4. /build/src/DataTypes/DataTypeDecimalBase.h:77: DB::DataTypeDecimalBase>>::DataTypeDecimalBase(unsigned int, unsigned int) @ 0x0000000013bde105 5. /build/src/DataTypes/DataTypesDecimal.h:39: auto auto bool DB::FunctionBinaryArithmetic::castBothTypes::getReturnTypeImplStatic(std::vector, std::allocator>> const&, std::shared_ptr)::'lambda'(auto const&, auto const&)>(DB::IDataType const*, DB::IDataType const*, auto&&)::'lambda'(auto const&)::operator()>>>(auto const&) const::'lambda'(auto const&)::operator()>>>(auto const&) const @ 0x000000000dae8ee1 6. /build/src/Functions/castTypeToEither.h:18: bool DB::FunctionBinaryArithmetic::castType::castBothTypes::getReturnTypeImplStatic(std::vector, std::allocator>> const&, std::shared_ptr)::'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&&) @ 0x000000000dae8b38 7. /build/src/Functions/FunctionBinaryArithmetic.h:846: bool DB::FunctionBinaryArithmetic::castType::castBothTypes::getReturnTypeImplStatic(std::vector, std::allocator>> const&, std::shared_ptr)::'lambda'(auto const&, auto const&)>(DB::IDataType const*, DB::IDataType const*, auto&&)::'lambda'(auto const&)>(DB::IDataType const*, auto&&) @ 0x000000000dae05a3 8. /build/src/Functions/FunctionBinaryArithmetic.h:844: DB::FunctionBinaryArithmetic::getReturnTypeImplStatic(std::vector, std::allocator>> const&, std::shared_ptr) @ 0x000000000dadf6d2 9. /build/src/Functions/IFunction.h:369: DB::IFunctionOverloadResolver::getReturnTypeImpl(std::vector> const&) const @ 0x000000000a6646de 10. /build/src/Functions/IFunction.cpp:645: DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x0000000012d96b0c 11. /build/src/Functions/IFunction.cpp:577: DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x0000000012d9669c 12. /build/src/Functions/IFunction.cpp:606: DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x0000000012d96edc 13. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3544: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000014033cc9 14. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3838: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000014019a9e 15. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3980: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000014018e31 16. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:4304: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000014042fa7 17. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5605: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000014013749 18. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000140127f9 19. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000014011fce 20. /build/src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000001406ce8a 21. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000014973b42 22. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000001497268d 23. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000014974d24 24. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001492924b 25. /build/src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88641 26. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 27. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 28. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 29. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 30. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 31. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 2025.07.28 11:53:18.912864 [ 3950 ] {448ac907-4a90-4f55-a4c3-4fe5d2b48cad::201403_1_9_2} virtual bool DB::MergePlainMergeTreeTask::executeStep(): Exception is in merge_task.: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=23, jobs=0). (CANNOT_SCHEDULE_TASK), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000fccaeeb 4. /build/src/Common/ThreadPool.cpp:275: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000fccc813 5. /build/src/Common/ThreadPool.cpp:323: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fcc7bbc 6. /build/src/Common/ThreadPool.cpp:494: ThreadPoolImpl>::scheduleOrThrowOnError(std::function, Priority) @ 0x000000000fcc7a0e 7. /build/src/Common/threadPoolCallbackRunner.h:52: std::future> std::__function::__policy_invoker> (DB::MergeTreeMarksLoader::loadMarksAsync()::$_0&&, Priority)>::__call_impl[abi:se190107]> (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&&) @ 0x0000000016474731 8. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000016471940 9. /build/src/Storages/MergeTree/MergeTreeMarksLoader.cpp:83: DB::MergeTreeMarksLoader::startAsyncLoad() @ 0x000000001647173f 10. /build/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) @ 0x000000001648df37 11. /build/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&&) @ 0x00000000163c608d 12. /build/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 @ 0x00000000163c27d4 13. /build/src/Storages/MergeTree/MergeTreeReadTask.cpp:60: DB::MergeTreeReadTask::createReaders(std::shared_ptr const&, DB::MergeTreeReadTask::Extras const&, DB::MarkRanges const&) @ 0x00000000164b5386 14. /build/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) @ 0x00000000164ae717 15. /build/contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: DB::MergeTreeSequentialSource* std::construct_at[abi:se190107] 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&) @ 0x00000000164b4832 16. /build/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) @ 0x00000000164b091a 17. /build/src/Storages/MergeTree/MergeTreeSequentialSource.cpp:384: DB::ReadFromPart::initializePipeline(DB::QueryPipelineBuilder&, DB::BuildQueryPipelineSettings const&) @ 0x00000000164b31ca 18. /build/src/Processors/QueryPlan/ISourceStep.cpp:20: DB::ISourceStep::updatePipeline(std::vector>, std::allocator>>>, DB::BuildQueryPipelineSettings const&) @ 0x0000000016dd18d0 19. /build/src/Processors/QueryPlan/QueryPlan.cpp:201: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x0000000016e0076f 20. /build/src/Storages/MergeTree/MergeTask.cpp:1125: DB::MergeTask::VerticalMergeStage::createPipelineForReadingOneColumn(String const&) const @ 0x00000000162d8d13 21. /build/src/Storages/MergeTree/MergeTask.cpp:1149: DB::MergeTask::VerticalMergeStage::prepareVerticalMergeForOneColumn() const @ 0x00000000162d96ce 22. /build/src/Storages/MergeTree/MergeTask.cpp:1457: DB::MergeTask::VerticalMergeStage::executeVerticalMergeForAllColumns() const @ 0x00000000162dc978 23. /build/src/Storages/MergeTree/MergeTask.cpp:1392: DB::MergeTask::VerticalMergeStage::execute() @ 0x00000000162dc4f9 24. /build/src/Storages/MergeTree/MergeTask.cpp:1485: DB::MergeTask::execute() @ 0x00000000162dbf2a 25. /build/src/Storages/MergeTree/MergePlainMergeTreeTask.cpp:57: DB::MergePlainMergeTreeTask::executeStep() @ 0x000000001666e865 26. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000162fc850 27. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x00000000162fd193 28. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc6653 29. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000000fccc4c3 30. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc3d92 31. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fcca080 (version 25.3.6.10636.altinitytest (altinity build)) 2025.07.28 11:53:18.919402 [ 3950 ] {} MergeTreeBackgroundExecutor: Exception while executing background task {448ac907-4a90-4f55-a4c3-4fe5d2b48cad::201403_1_9_2}: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=23, jobs=0). (CANNOT_SCHEDULE_TASK), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000fccaeeb 4. /build/src/Common/ThreadPool.cpp:275: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000fccc813 5. /build/src/Common/ThreadPool.cpp:323: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fcc7bbc 6. /build/src/Common/ThreadPool.cpp:494: ThreadPoolImpl>::scheduleOrThrowOnError(std::function, Priority) @ 0x000000000fcc7a0e 7. /build/src/Common/threadPoolCallbackRunner.h:52: std::future> std::__function::__policy_invoker> (DB::MergeTreeMarksLoader::loadMarksAsync()::$_0&&, Priority)>::__call_impl[abi:se190107]> (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&&) @ 0x0000000016474731 8. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000016471940 9. /build/src/Storages/MergeTree/MergeTreeMarksLoader.cpp:83: DB::MergeTreeMarksLoader::startAsyncLoad() @ 0x000000001647173f 10. /build/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) @ 0x000000001648df37 11. /build/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&&) @ 0x00000000163c608d 12. /build/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 @ 0x00000000163c27d4 13. /build/src/Storages/MergeTree/MergeTreeReadTask.cpp:60: DB::MergeTreeReadTask::createReaders(std::shared_ptr const&, DB::MergeTreeReadTask::Extras const&, DB::MarkRanges const&) @ 0x00000000164b5386 14. /build/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) @ 0x00000000164ae717 15. /build/contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: DB::MergeTreeSequentialSource* std::construct_at[abi:se190107] 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&) @ 0x00000000164b4832 16. /build/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) @ 0x00000000164b091a 17. /build/src/Storages/MergeTree/MergeTreeSequentialSource.cpp:384: DB::ReadFromPart::initializePipeline(DB::QueryPipelineBuilder&, DB::BuildQueryPipelineSettings const&) @ 0x00000000164b31ca 18. /build/src/Processors/QueryPlan/ISourceStep.cpp:20: DB::ISourceStep::updatePipeline(std::vector>, std::allocator>>>, DB::BuildQueryPipelineSettings const&) @ 0x0000000016dd18d0 19. /build/src/Processors/QueryPlan/QueryPlan.cpp:201: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x0000000016e0076f 20. /build/src/Storages/MergeTree/MergeTask.cpp:1125: DB::MergeTask::VerticalMergeStage::createPipelineForReadingOneColumn(String const&) const @ 0x00000000162d8d13 21. /build/src/Storages/MergeTree/MergeTask.cpp:1149: DB::MergeTask::VerticalMergeStage::prepareVerticalMergeForOneColumn() const @ 0x00000000162d96ce 22. /build/src/Storages/MergeTree/MergeTask.cpp:1457: DB::MergeTask::VerticalMergeStage::executeVerticalMergeForAllColumns() const @ 0x00000000162dc978 23. /build/src/Storages/MergeTree/MergeTask.cpp:1392: DB::MergeTask::VerticalMergeStage::execute() @ 0x00000000162dc4f9 24. /build/src/Storages/MergeTree/MergeTask.cpp:1485: DB::MergeTask::execute() @ 0x00000000162dbf2a 25. /build/src/Storages/MergeTree/MergePlainMergeTreeTask.cpp:57: DB::MergePlainMergeTreeTask::executeStep() @ 0x000000001666e865 26. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000162fc850 27. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x00000000162fd193 28. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc6653 29. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000000fccc4c3 30. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc3d92 31. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fcca080 (version 25.3.6.10636.altinitytest (altinity build)) 2025.07.28 11:53:19.063397 [ 3977 ] {} test_13.rmt2 (7f9b740d-015c-470e-8cc6-8ba33be0dc63): auto DB::StorageReplicatedMergeTree::processQueueEntry(ReplicatedMergeTreeQueue::SelectedEntryPtr)::(anonymous class)::operator()(LogEntryPtr &) const: Code: 86. DB::HTTPException: Received error from remote server http://146b4357c08d:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Ftest%2F01165%2Ftest_13%2Frmt%2Freplicas%2F1&part=20250728_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.6.10636.altinitytest (altinity build)) '. (RECEIVED_ERROR_FROM_REMOTE_IO_SERVER), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.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 const&, int&&, String const&, unsigned long&&, String const&) @ 0x000000000feda8d9 4. /build/src/IO/HTTPCommon.cpp:104: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x000000000feda6e2 5. /build/src/IO/HTTPCommon.cpp:93: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x000000000feda537 6. /build/src/IO/ReadWriteBufferFromHTTP.cpp:277: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x000000001184a4c4 7. /build/src/IO/ReadWriteBufferFromHTTP.cpp:285: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x000000001184a615 8. /build/src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x000000001184ae59 9. /build/src/IO/ReadWriteBufferFromHTTP.cpp:472: void std::__function::__policy_invoker::__call_impl[abi:se190107]>(std::__function::__policy_storage const*) @ 0x000000001184cedd 10. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001184858b 11. /build/src/IO/ReadWriteBufferFromHTTP.cpp:465: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x000000001184bf0b 12. /build/src/IO/ReadBuffer.h:60: DB::ReadBuffer::next() @ 0x000000000a148c7b 13. /build/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) @ 0x0000000011849fb2 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]>&)>&, 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&) @ 0x0000000011841980 15. /build/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) @ 0x000000001621208e 16. /build/src/Storages/StorageReplicatedMergeTree.cpp:5228: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl[abi:se190107] const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000015f9a5fe 17. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000015ed8bfd 18. /build/src/Storages/StorageReplicatedMergeTree.cpp:2514: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x0000000015ec9aab 19. /build/src/Storages/StorageReplicatedMergeTree.cpp:2349: DB::StorageReplicatedMergeTree::executeLogEntry(DB::ReplicatedMergeTreeLogEntry&) @ 0x0000000015eba91b 20. /build/src/Storages/StorageReplicatedMergeTree.cpp:3876: bool std::__function::__policy_invoker&)>::__call_impl[abi:se190107])::$_1, bool (std::shared_ptr&)>>(std::__function::__policy_storage const*, std::shared_ptr&) @ 0x0000000015f9837e 21. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000165d6fc3 22. /build/src/Storages/StorageReplicatedMergeTree.cpp:3872: DB::StorageReplicatedMergeTree::processQueueEntry(std::shared_ptr) @ 0x0000000015efc18a 23. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001624c1b2 24. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000162f9c70 25. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x00000000162fa55a 26. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc6653 27. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000000fccc4c3 28. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc3d92 29. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fcca080 30. ? @ 0x00007fbc6213eac3 31. ? @ 0x00007fbc621d0850 (version 25.3.6.10636.altinitytest (altinity build)) 2025.07.28 11:53:19.268996 [ 3970 ] {} test_13.rmt2 (7f9b740d-015c-470e-8cc6-8ba33be0dc63): auto DB::StorageReplicatedMergeTree::processQueueEntry(ReplicatedMergeTreeQueue::SelectedEntryPtr)::(anonymous class)::operator()(LogEntryPtr &) const: Code: 86. DB::HTTPException: Received error from remote server http://146b4357c08d:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Ftest%2F01165%2Ftest_13%2Frmt%2Freplicas%2F1&part=20250728_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.6.10636.altinitytest (altinity build)) '. (RECEIVED_ERROR_FROM_REMOTE_IO_SERVER), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.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 const&, int&&, String const&, unsigned long&&, String const&) @ 0x000000000feda8d9 4. /build/src/IO/HTTPCommon.cpp:104: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x000000000feda6e2 5. /build/src/IO/HTTPCommon.cpp:93: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x000000000feda537 6. /build/src/IO/ReadWriteBufferFromHTTP.cpp:277: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x000000001184a4c4 7. /build/src/IO/ReadWriteBufferFromHTTP.cpp:285: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x000000001184a615 8. /build/src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x000000001184ae59 9. /build/src/IO/ReadWriteBufferFromHTTP.cpp:472: void std::__function::__policy_invoker::__call_impl[abi:se190107]>(std::__function::__policy_storage const*) @ 0x000000001184cedd 10. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001184858b 11. /build/src/IO/ReadWriteBufferFromHTTP.cpp:465: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x000000001184bf0b 12. /build/src/IO/ReadBuffer.h:60: DB::ReadBuffer::next() @ 0x000000000a148c7b 13. /build/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) @ 0x0000000011849fb2 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]>&)>&, 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&) @ 0x0000000011841980 15. /build/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) @ 0x000000001621208e 16. /build/src/Storages/StorageReplicatedMergeTree.cpp:5228: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl[abi:se190107] const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000015f9a5fe 17. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000015ed8bfd 18. /build/src/Storages/StorageReplicatedMergeTree.cpp:2514: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x0000000015ec9aab 19. /build/src/Storages/StorageReplicatedMergeTree.cpp:2349: DB::StorageReplicatedMergeTree::executeLogEntry(DB::ReplicatedMergeTreeLogEntry&) @ 0x0000000015eba91b 20. /build/src/Storages/StorageReplicatedMergeTree.cpp:3876: bool std::__function::__policy_invoker&)>::__call_impl[abi:se190107])::$_1, bool (std::shared_ptr&)>>(std::__function::__policy_storage const*, std::shared_ptr&) @ 0x0000000015f9837e 21. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000165d6fc3 22. /build/src/Storages/StorageReplicatedMergeTree.cpp:3872: DB::StorageReplicatedMergeTree::processQueueEntry(std::shared_ptr) @ 0x0000000015efc18a 23. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001624c1b2 24. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000162f9c70 25. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x00000000162fa55a 26. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc6653 27. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000000fccc4c3 28. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc3d92 29. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fcca080 30. ? @ 0x00007fbc6213eac3 31. ? @ 0x00007fbc621d0850 (version 25.3.6.10636.altinitytest (altinity build)) 2025.07.28 11:53:19.457760 [ 5112 ] {1b89cd1c-bbed-4350-bbfb-59fb202ee94e} executeQuery: Code: 407. DB::Exception: Decimal math overflow: while executing 'FUNCTION multiply(__table1.h : 0, __table1.h : 0) -> multiply(__table1.h, __table1.h) Decimal(18, 18) : 3'. (DECIMAL_OVERFLOW) (version 25.3.6.10636.altinitytest (altinity build)) (from [::1]:48688) (comment: 00700_decimal_arithm.sql) (query 12, line 32) (in query: SELECT h + h, h - h, h * h, h / h, intDiv(h, h), intDivOrZero(h, h) FROM decimal WHERE h > 0;), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000000a074fcb 4. /build/src/Functions/FunctionBinaryArithmetic.h:735: void DB::impl_::DecimalBinaryOperation, true>::processWithRightNullmapImpl<(DB::impl_::OpCase)0, void DB::impl_::DecimalBinaryOperation, true>::process<(DB::impl_::OpCase)0, true, true, DB::PODArray, 4096ul, Allocator, 63ul, 64ul>, DB::PODArray, 4096ul, Allocator, 63ul, 64ul>>(DB::PODArray, 4096ul, Allocator, 63ul, 64ul> const&, DB::PODArray, 4096ul, Allocator, 63ul, 64ul> const&, DB::PODArray, 4096ul, Allocator, 63ul, 64ul>&, long, long, DB::PODArray, 63ul, 64ul> const*)::'lambda'(auto const&, auto const&), DB::PODArray, 4096ul, Allocator, 63ul, 64ul>, DB::PODArray, 4096ul, Allocator, 63ul, 64ul>>(DB::PODArray, 4096ul, Allocator, 63ul, 64ul> const&, DB::PODArray, 4096ul, Allocator, 63ul, 64ul> const&, DB::PODArray, 4096ul, Allocator, 63ul, 64ul>&, unsigned long, DB::PODArray, 63ul, 64ul> const*, auto) @ 0x000000000d9c7410 5. /build/src/Functions/FunctionBinaryArithmetic.h:1485: COW::immutable_ptr DB::FunctionBinaryArithmetic::executeNumericWithDecimal>, DB::DataTypeDecimal>, DB::DataTypeDecimal>, DB::DataTypeDecimal>, DB::DataTypeDecimal>, DB::ColumnDecimal>, DB::ColumnDecimal>>(DB::DataTypeDecimal> const&, DB::DataTypeDecimal> const&, DB::ColumnConst const*, DB::ColumnConst const*, DB::ColumnDecimal> const*, DB::ColumnDecimal> const*, unsigned long, DB::PODArray, 63ul, 64ul> const*) const @ 0x000000000daa6247 6. /build/src/Functions/FunctionBinaryArithmetic.h:2270: COW::immutable_ptr DB::FunctionBinaryArithmetic::executeNumeric>, DB::DataTypeDecimal>>(std::vector> const&, DB::DataTypeDecimal> const&, DB::DataTypeDecimal> const&, DB::PODArray, 63ul, 64ul> const*) const @ 0x000000000daa5f79 7. /build/src/Functions/FunctionBinaryArithmetic.h:2508: auto auto bool DB::FunctionBinaryArithmetic::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&)::operator()>>(auto const&) const @ 0x000000000da9eb67 8. /build/src/Functions/castTypeToEither.h:18: 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&&) @ 0x000000000da9e6b0 9. /build/src/Functions/FunctionBinaryArithmetic.h:846: 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&&) @ 0x000000000da23a43 10. /build/src/Functions/FunctionBinaryArithmetic.h:844: DB::FunctionBinaryArithmetic::executeImpl2(std::vector> const&, std::shared_ptr const&, unsigned long, DB::PODArray, 63ul, 64ul> const*) const @ 0x000000000da1f8c5 11. /build/src/Functions/FunctionBinaryArithmetic.h:2410: DB::FunctionBinaryArithmetic::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000da1d523 12. /build/src/Functions/IFunctionAdaptors.cpp:10: DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000012d995fa 13. /build/src/Functions/IFunction.cpp:353: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d93b52 14. /build/src/Functions/IFunction.cpp:420: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d95059 15. /build/src/Functions/IFunction.cpp:498: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d95c72 16. /build/src/Interpreters/ExpressionActions.cpp:636: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x00000000145176f3 17. /build/src/Processors/Transforms/ExpressionTransform.cpp:25: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x0000000016c0b34c 18. /build/src/Processors/ISimpleTransform.h:33: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000011a9a453 19. /build/src/Processors/ISimpleTransform.cpp:89: DB::ISimpleTransform::work() @ 0x000000001699fca0 20. /build/src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x00000000169bd00f 21. /build/src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x00000000169b2105 22. /build/src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeSingleThread(unsigned long) @ 0x00000000169b23be 23. /build/src/Processors/Executors/PipelineExecutor.cpp:416: void std::__function::__policy_invoker::__call_impl[abi:se190107]>(std::__function::__policy_storage const*) @ 0x00000000169b2e3f 24. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc6653 25. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000000fccc4c3 26. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc3d92 27. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fcca080 28. ? @ 0x00007fbc6213eac3 29. ? @ 0x00007fbc621d0850 2025.07.28 11:53:19.483657 [ 5112 ] {} TCPHandler: Code: 407. DB::Exception: Decimal math overflow: while executing 'FUNCTION multiply(__table1.h : 0, __table1.h : 0) -> multiply(__table1.h, __table1.h) Decimal(18, 18) : 3'. (DECIMAL_OVERFLOW), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000000a074fcb 4. /build/src/Functions/FunctionBinaryArithmetic.h:735: void DB::impl_::DecimalBinaryOperation, true>::processWithRightNullmapImpl<(DB::impl_::OpCase)0, void DB::impl_::DecimalBinaryOperation, true>::process<(DB::impl_::OpCase)0, true, true, DB::PODArray, 4096ul, Allocator, 63ul, 64ul>, DB::PODArray, 4096ul, Allocator, 63ul, 64ul>>(DB::PODArray, 4096ul, Allocator, 63ul, 64ul> const&, DB::PODArray, 4096ul, Allocator, 63ul, 64ul> const&, DB::PODArray, 4096ul, Allocator, 63ul, 64ul>&, long, long, DB::PODArray, 63ul, 64ul> const*)::'lambda'(auto const&, auto const&), DB::PODArray, 4096ul, Allocator, 63ul, 64ul>, DB::PODArray, 4096ul, Allocator, 63ul, 64ul>>(DB::PODArray, 4096ul, Allocator, 63ul, 64ul> const&, DB::PODArray, 4096ul, Allocator, 63ul, 64ul> const&, DB::PODArray, 4096ul, Allocator, 63ul, 64ul>&, unsigned long, DB::PODArray, 63ul, 64ul> const*, auto) @ 0x000000000d9c7410 5. /build/src/Functions/FunctionBinaryArithmetic.h:1485: COW::immutable_ptr DB::FunctionBinaryArithmetic::executeNumericWithDecimal>, DB::DataTypeDecimal>, DB::DataTypeDecimal>, DB::DataTypeDecimal>, DB::DataTypeDecimal>, DB::ColumnDecimal>, DB::ColumnDecimal>>(DB::DataTypeDecimal> const&, DB::DataTypeDecimal> const&, DB::ColumnConst const*, DB::ColumnConst const*, DB::ColumnDecimal> const*, DB::ColumnDecimal> const*, unsigned long, DB::PODArray, 63ul, 64ul> const*) const @ 0x000000000daa6247 6. /build/src/Functions/FunctionBinaryArithmetic.h:2270: COW::immutable_ptr DB::FunctionBinaryArithmetic::executeNumeric>, DB::DataTypeDecimal>>(std::vector> const&, DB::DataTypeDecimal> const&, DB::DataTypeDecimal> const&, DB::PODArray, 63ul, 64ul> const*) const @ 0x000000000daa5f79 7. /build/src/Functions/FunctionBinaryArithmetic.h:2508: auto auto bool DB::FunctionBinaryArithmetic::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&)::operator()>>(auto const&) const @ 0x000000000da9eb67 8. /build/src/Functions/castTypeToEither.h:18: 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&&) @ 0x000000000da9e6b0 9. /build/src/Functions/FunctionBinaryArithmetic.h:846: 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&&) @ 0x000000000da23a43 10. /build/src/Functions/FunctionBinaryArithmetic.h:844: DB::FunctionBinaryArithmetic::executeImpl2(std::vector> const&, std::shared_ptr const&, unsigned long, DB::PODArray, 63ul, 64ul> const*) const @ 0x000000000da1f8c5 11. /build/src/Functions/FunctionBinaryArithmetic.h:2410: DB::FunctionBinaryArithmetic::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000da1d523 12. /build/src/Functions/IFunctionAdaptors.cpp:10: DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000012d995fa 13. /build/src/Functions/IFunction.cpp:353: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d93b52 14. /build/src/Functions/IFunction.cpp:420: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d95059 15. /build/src/Functions/IFunction.cpp:498: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d95c72 16. /build/src/Interpreters/ExpressionActions.cpp:636: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x00000000145176f3 17. /build/src/Processors/Transforms/ExpressionTransform.cpp:25: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x0000000016c0b34c 18. /build/src/Processors/ISimpleTransform.h:33: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000011a9a453 19. /build/src/Processors/ISimpleTransform.cpp:89: DB::ISimpleTransform::work() @ 0x000000001699fca0 20. /build/src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x00000000169bd00f 21. /build/src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x00000000169b2105 22. /build/src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeSingleThread(unsigned long) @ 0x00000000169b23be 23. /build/src/Processors/Executors/PipelineExecutor.cpp:416: void std::__function::__policy_invoker::__call_impl[abi:se190107]>(std::__function::__policy_storage const*) @ 0x00000000169b2e3f 24. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc6653 25. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000000fccc4c3 26. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc3d92 27. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fcca080 28. ? @ 0x00007fbc6213eac3 29. ? @ 0x00007fbc621d0850 Job's origin stack trace: 0. /build/src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000000fc33b84 1. /build/src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000000fcc2ea7 2. /build/src/Common/ThreadPool.cpp:401: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fcc7f1c 3. /build/src/Common/ThreadPool.cpp:494: ThreadPoolImpl>::scheduleOrThrowOnError(std::function, Priority) @ 0x000000000fcc7a0e 4. /build/src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::spawnThreadsImpl() @ 0x00000000169b2c0c 5. /build/src/Processors/Executors/PipelineExecutor.cpp:394: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x00000000169b0ba7 6. /build/src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x00000000169b03f4 7. /build/src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:se190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169bfeab 8. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc3d92 9. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fcca080 10. ? @ 0x00007fbc6213eac3 11. ? @ 0x00007fbc621d0850 Job's origin stack trace: 0. /build/src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000000fc33b84 1. /build/src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000000fcc2ea7 2. /build/src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fcc535c 3. /build/src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000000fcc584d 4. /build/src/Common/ThreadPool.h:279: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x00000000169bf193 5. /build/src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x00000000169bf518 6. /build/src/Server/TCPHandler.cpp:1237: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x00000000168f1525 7. /build/src/Server/TCPHandler.cpp:678: DB::TCPHandler::runImpl() @ 0x00000000168e68e5 8. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 9. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 10. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 11. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 12. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 13. ? @ 0x00007fbc6213eac3 14. ? @ 0x00007fbc621d0850 2025.07.28 11:53:20.105954 [ 17207 ] {19350798-723d-4848-8343-f2c15ea7068a} executeQuery: Code: 676. DB::Exception: Invalid IPv6 value: In scope SELECT IPv6StringToNum('test'). (CANNOT_PARSE_IPV6) (version 25.3.6.10636.altinitytest (altinity build)) (from [::1]:48582) (comment: 02234_cast_to_ip_address.sql) (query 33, line 48) (in query: SELECT IPv6StringToNum('test');), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000000a074fcb 4. /build/src/Functions/FunctionsCodingIP.h:198: COW::immutable_ptr DB::detail::convertToIPv6<(DB::IPStringToNumExceptionMode)0, DB::ColumnFixedString, DB::ColumnString>(DB::ColumnString const&, DB::PODArray, 63ul, 64ul> const*) @ 0x000000000a11583f 5. /build/src/Functions/FunctionsCodingIP.h:220: COW::immutable_ptr DB::convertToIPv6<(DB::IPStringToNumExceptionMode)0, DB::ColumnFixedString>(COW::immutable_ptr, DB::PODArray, 63ul, 64ul> const*) @ 0x000000000a1145b0 6. /build/src/Functions/FunctionsCodingIP.cpp:341: DB::FunctionIPv6StringToNum<(DB::IPStringToNumExceptionMode)0>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000a113cca 7. /build/src/Functions/IFunction.h:437: DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000a069f2a 8. /build/src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000012d9965a 9. /build/src/Functions/IFunction.cpp:351: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d93b02 10. /build/src/Functions/IFunction.cpp:177: DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d93698 11. /build/src/Functions/IFunction.cpp:343: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d93aad 12. /build/src/Functions/IFunction.cpp:420: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d95059 13. /build/src/Functions/IFunction.cpp:498: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d95c72 14. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3567: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000014034494 15. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3838: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000014019a9e 16. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3980: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000014018e31 17. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:4304: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000014042fa7 18. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5605: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000014013749 19. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000140127f9 20. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000014011fce 21. /build/src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000001406ce8a 22. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000014973b42 23. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000001497268d 24. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000014974d24 25. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001492924b 26. /build/src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88641 27. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 28. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 29. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 30. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 31. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 2025.07.28 11:53:20.118389 [ 17207 ] {} TCPHandler: Code: 676. DB::Exception: Invalid IPv6 value: In scope SELECT IPv6StringToNum('test'). (CANNOT_PARSE_IPV6), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000000a074fcb 4. /build/src/Functions/FunctionsCodingIP.h:198: COW::immutable_ptr DB::detail::convertToIPv6<(DB::IPStringToNumExceptionMode)0, DB::ColumnFixedString, DB::ColumnString>(DB::ColumnString const&, DB::PODArray, 63ul, 64ul> const*) @ 0x000000000a11583f 5. /build/src/Functions/FunctionsCodingIP.h:220: COW::immutable_ptr DB::convertToIPv6<(DB::IPStringToNumExceptionMode)0, DB::ColumnFixedString>(COW::immutable_ptr, DB::PODArray, 63ul, 64ul> const*) @ 0x000000000a1145b0 6. /build/src/Functions/FunctionsCodingIP.cpp:341: DB::FunctionIPv6StringToNum<(DB::IPStringToNumExceptionMode)0>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000a113cca 7. /build/src/Functions/IFunction.h:437: DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000a069f2a 8. /build/src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000012d9965a 9. /build/src/Functions/IFunction.cpp:351: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d93b02 10. /build/src/Functions/IFunction.cpp:177: DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d93698 11. /build/src/Functions/IFunction.cpp:343: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d93aad 12. /build/src/Functions/IFunction.cpp:420: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d95059 13. /build/src/Functions/IFunction.cpp:498: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d95c72 14. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3567: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000014034494 15. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3838: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000014019a9e 16. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3980: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000014018e31 17. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:4304: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000014042fa7 18. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5605: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000014013749 19. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000140127f9 20. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000014011fce 21. /build/src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000001406ce8a 22. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000014973b42 23. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000001497268d 24. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000014974d24 25. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001492924b 26. /build/src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88641 27. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 28. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 29. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 30. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 31. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 2025.07.28 11:53:20.345032 [ 3960 ] {} test_13.rmt2 (7f9b740d-015c-470e-8cc6-8ba33be0dc63): auto DB::StorageReplicatedMergeTree::processQueueEntry(ReplicatedMergeTreeQueue::SelectedEntryPtr)::(anonymous class)::operator()(LogEntryPtr &) const: Code: 86. DB::HTTPException: Received error from remote server http://146b4357c08d:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Ftest%2F01165%2Ftest_13%2Frmt%2Freplicas%2F1&part=20250728_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.6.10636.altinitytest (altinity build)) '. (RECEIVED_ERROR_FROM_REMOTE_IO_SERVER), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.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 const&, int&&, String const&, unsigned long&&, String const&) @ 0x000000000feda8d9 4. /build/src/IO/HTTPCommon.cpp:104: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x000000000feda6e2 5. /build/src/IO/HTTPCommon.cpp:93: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x000000000feda537 6. /build/src/IO/ReadWriteBufferFromHTTP.cpp:277: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x000000001184a4c4 7. /build/src/IO/ReadWriteBufferFromHTTP.cpp:285: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x000000001184a615 8. /build/src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x000000001184ae59 9. /build/src/IO/ReadWriteBufferFromHTTP.cpp:472: void std::__function::__policy_invoker::__call_impl[abi:se190107]>(std::__function::__policy_storage const*) @ 0x000000001184cedd 10. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001184858b 11. /build/src/IO/ReadWriteBufferFromHTTP.cpp:465: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x000000001184bf0b 12. /build/src/IO/ReadBuffer.h:60: DB::ReadBuffer::next() @ 0x000000000a148c7b 13. /build/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) @ 0x0000000011849fb2 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]>&)>&, 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&) @ 0x0000000011841980 15. /build/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) @ 0x000000001621208e 16. /build/src/Storages/StorageReplicatedMergeTree.cpp:5228: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl[abi:se190107] const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000015f9a5fe 17. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000015ed8bfd 18. /build/src/Storages/StorageReplicatedMergeTree.cpp:2514: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x0000000015ec9aab 19. /build/src/Storages/StorageReplicatedMergeTree.cpp:2349: DB::StorageReplicatedMergeTree::executeLogEntry(DB::ReplicatedMergeTreeLogEntry&) @ 0x0000000015eba91b 20. /build/src/Storages/StorageReplicatedMergeTree.cpp:3876: bool std::__function::__policy_invoker&)>::__call_impl[abi:se190107])::$_1, bool (std::shared_ptr&)>>(std::__function::__policy_storage const*, std::shared_ptr&) @ 0x0000000015f9837e 21. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000165d6fc3 22. /build/src/Storages/StorageReplicatedMergeTree.cpp:3872: DB::StorageReplicatedMergeTree::processQueueEntry(std::shared_ptr) @ 0x0000000015efc18a 23. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001624c1b2 24. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000162f9c70 25. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x00000000162fa55a 26. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc6653 27. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000000fccc4c3 28. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc3d92 29. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fcca080 30. ? @ 0x00007fbc6213eac3 31. ? @ 0x00007fbc621d0850 (version 25.3.6.10636.altinitytest (altinity build)) 2025.07.28 11:53:20.940151 [ 17243 ] {1babd3c8-9e66-426b-b2d1-2ae23d82a1dd} executeQuery: Code: 69. DB::Exception: The argument 'resolution' (16) of function h3NumHexagons is out of bounds because the maximum resolution in H3 library is 15: In scope SELECT h3NumHexagons(16). (ARGUMENT_OUT_OF_BOUND) (version 25.3.6.10636.altinitytest (altinity build)) (from [::1]:48822) (comment: 02165_h3_num_hexagons.sql) (query 17, line 19) (in query: SELECT h3NumHexagons(16);), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, int&&) @ 0x000000000ba5618b 4. /build/src/Functions/h3NumHexagons.cpp:83: DB::(anonymous namespace)::FunctionH3NumHexagons::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000c22d6cb 5. /build/src/Functions/IFunction.h:437: DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000a069f2a 6. /build/src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000012d9965a 7. /build/src/Functions/IFunction.cpp:351: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d93b02 8. /build/src/Functions/IFunction.cpp:177: DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d93698 9. /build/src/Functions/IFunction.cpp:343: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d93aad 10. /build/src/Functions/IFunction.cpp:420: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d95059 11. /build/src/Functions/IFunction.cpp:498: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d95c72 12. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3567: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000014034494 13. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3838: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000014019a9e 14. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3980: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000014018e31 15. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:4304: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000014042fa7 16. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5605: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000014013749 17. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000140127f9 18. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000014011fce 19. /build/src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000001406ce8a 20. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000014973b42 21. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000001497268d 22. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000014974d24 23. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001492924b 24. /build/src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88641 25. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 26. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 27. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 28. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 29. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 30. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 31. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 2025.07.28 11:53:20.947289 [ 17243 ] {} TCPHandler: Code: 69. DB::Exception: The argument 'resolution' (16) of function h3NumHexagons is out of bounds because the maximum resolution in H3 library is 15: In scope SELECT h3NumHexagons(16). (ARGUMENT_OUT_OF_BOUND), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, int&&) @ 0x000000000ba5618b 4. /build/src/Functions/h3NumHexagons.cpp:83: DB::(anonymous namespace)::FunctionH3NumHexagons::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000c22d6cb 5. /build/src/Functions/IFunction.h:437: DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000a069f2a 6. /build/src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000012d9965a 7. /build/src/Functions/IFunction.cpp:351: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d93b02 8. /build/src/Functions/IFunction.cpp:177: DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d93698 9. /build/src/Functions/IFunction.cpp:343: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d93aad 10. /build/src/Functions/IFunction.cpp:420: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d95059 11. /build/src/Functions/IFunction.cpp:498: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d95c72 12. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3567: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000014034494 13. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3838: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000014019a9e 14. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3980: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000014018e31 15. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:4304: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000014042fa7 16. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5605: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000014013749 17. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000140127f9 18. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000014011fce 19. /build/src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000001406ce8a 20. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000014973b42 21. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000001497268d 22. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000014974d24 23. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001492924b 24. /build/src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88641 25. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 26. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 27. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 28. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 29. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 30. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 31. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 2025.07.28 11:53:21.111696 [ 5112 ] {6e10df45-9f44-416b-8a75-5a9c0a59d96f} executeQuery: Code: 407. DB::Exception: Decimal math overflow: while executing 'FUNCTION plus(__table1.e : 0, 21_UInt8 : 1) -> plus(__table1.e, 21_UInt8) Decimal(18, 18) : 4'. (DECIMAL_OVERFLOW) (version 25.3.6.10636.altinitytest (altinity build)) (from [::1]:48688) (comment: 00700_decimal_arithm.sql) (query 20, line 41) (in query: SELECT e + 21, e - 21, e - 84, e * 21, e * -21, e / 21, e / 84 FROM decimal WHERE e > 0;), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000000a074fcb 4. /build/src/Functions/FunctionBinaryArithmetic.h:763: void DB::impl_::DecimalBinaryOperation, true>::process<(DB::impl_::OpCase)2, true, false, DB::PODArray, 4096ul, Allocator, 63ul, 64ul>, long>(DB::PODArray, 4096ul, Allocator, 63ul, 64ul> const&, long const&, DB::PODArray, 4096ul, Allocator, 63ul, 64ul>&, long, long, DB::PODArray, 63ul, 64ul> const*) @ 0x000000000df0bd17 5. /build/src/Functions/FunctionBinaryArithmetic.h:1485: COW::immutable_ptr DB::FunctionBinaryArithmetic::executeNumericWithDecimal>, DB::DataTypeNumber, DB::DataTypeDecimal>, DB::DataTypeDecimal>, DB::DataTypeNumber, DB::ColumnDecimal>, DB::ColumnVector>(DB::DataTypeDecimal> const&, DB::DataTypeNumber const&, DB::ColumnConst const*, DB::ColumnConst const*, DB::ColumnDecimal> const*, DB::ColumnVector const*, unsigned long, DB::PODArray, 63ul, 64ul> const*) const @ 0x000000000dffd6de 6. /build/src/Functions/FunctionBinaryArithmetic.h:2270: COW::immutable_ptr DB::FunctionBinaryArithmetic::executeNumeric>, DB::DataTypeNumber>(std::vector> const&, DB::DataTypeDecimal> const&, DB::DataTypeNumber const&, DB::PODArray, 63ul, 64ul> const*) const @ 0x000000000dffd264 7. /build/src/Functions/FunctionBinaryArithmetic.h:2508: 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&&) @ 0x000000000dffc170 8. /build/src/Functions/FunctionBinaryArithmetic.h:846: 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&&) @ 0x000000000df74c83 9. /build/src/Functions/FunctionBinaryArithmetic.h:844: DB::FunctionBinaryArithmetic::executeImpl2(std::vector> const&, std::shared_ptr const&, unsigned long, DB::PODArray, 63ul, 64ul> const*) const @ 0x000000000df70b05 10. /build/src/Functions/FunctionBinaryArithmetic.h:2410: DB::FunctionBinaryArithmetic::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000df6e798 11. /build/src/Functions/FunctionBinaryArithmetic.h:2645: DB::FunctionBinaryArithmeticWithConstants::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000df6d494 12. /build/src/Functions/IFunctionAdaptors.cpp:10: DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000012d995fa 13. /build/src/Functions/IFunction.cpp:353: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d93b52 14. /build/src/Functions/IFunction.cpp:420: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d95059 15. /build/src/Functions/IFunction.cpp:498: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d95c72 16. /build/src/Interpreters/ExpressionActions.cpp:636: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x00000000145176f3 17. /build/src/Processors/Transforms/ExpressionTransform.cpp:25: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x0000000016c0b34c 18. /build/src/Processors/ISimpleTransform.h:33: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000011a9a453 19. /build/src/Processors/ISimpleTransform.cpp:89: DB::ISimpleTransform::work() @ 0x000000001699fca0 20. /build/src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x00000000169bd00f 21. /build/src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x00000000169b2105 22. /build/src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeSingleThread(unsigned long) @ 0x00000000169b23be 23. /build/src/Processors/Executors/PipelineExecutor.cpp:416: void std::__function::__policy_invoker::__call_impl[abi:se190107]>(std::__function::__policy_storage const*) @ 0x00000000169b2e3f 24. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc6653 25. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000000fccc4c3 26. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc3d92 27. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fcca080 28. ? @ 0x00007fbc6213eac3 29. ? @ 0x00007fbc621d0850 2025.07.28 11:53:21.157332 [ 17207 ] {ba7d428a-a985-4318-ba47-f875c2648328} executeQuery: Code: 676. DB::Exception: Cannot parse IPv6 test: Cannot parse IPv6 from String: In scope SELECT toIPv6('test'). (CANNOT_PARSE_IPV6) (version 25.3.6.10636.altinitytest (altinity build)) (from [::1]:48582) (comment: 02234_cast_to_ip_address.sql) (query 40, line 58) (in query: SELECT toIPv6('test');), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl>>::type>, std::basic_string_view>&&) @ 0x000000000a119c0b 4. /build/src/IO/ReadHelpers.h:993: COW::immutable_ptr DB::detail::ConvertThroughParsing::execute(std::vector> const&, std::shared_ptr const&, unsigned long, void*) @ 0x00000000130e0614 5. /build/src/Functions/FunctionsConversion.h:1580: COW::immutable_ptr DB::detail::ConvertImpl::execute(std::vector> const&, std::shared_ptr const&, unsigned long, DB::detail::BehaviourOnErrorFromString, void*) @ 0x00000000130e021e 6. /build/src/Functions/FunctionsConversion.h:2472: 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&&) @ 0x0000000012fab964 7. /build/src/Functions/FunctionsConversion.h:2527: DB::detail::FunctionConvert>>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000012fc9e94 8. /build/src/Functions/FunctionsConversion.h:2307: DB::detail::FunctionConvert>>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000012fc965a 9. /build/src/Functions/IFunction.h:437: DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000a069f2a 10. /build/src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000012d9965a 11. /build/src/Functions/IFunction.cpp:351: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d93b02 12. /build/src/Functions/IFunction.cpp:177: DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d93698 13. /build/src/Functions/IFunction.cpp:343: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d93aad 14. /build/src/Functions/IFunction.cpp:420: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d95059 15. /build/src/Functions/IFunction.cpp:498: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d95c72 16. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3567: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000014034494 17. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3838: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000014019a9e 18. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3980: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000014018e31 19. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:4304: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000014042fa7 20. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5605: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000014013749 21. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000140127f9 22. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000014011fce 23. /build/src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000001406ce8a 24. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000014973b42 25. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000001497268d 26. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000014974d24 27. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001492924b 28. /build/src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88641 29. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 30. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 31. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 2025.07.28 11:53:21.166360 [ 3968 ] {} test_13.rmt2 (7f9b740d-015c-470e-8cc6-8ba33be0dc63): auto DB::StorageReplicatedMergeTree::processQueueEntry(ReplicatedMergeTreeQueue::SelectedEntryPtr)::(anonymous class)::operator()(LogEntryPtr &) const: Code: 86. DB::HTTPException: Received error from remote server http://146b4357c08d:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Ftest%2F01165%2Ftest_13%2Frmt%2Freplicas%2F1&part=20250728_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.6.10636.altinitytest (altinity build)) '. (RECEIVED_ERROR_FROM_REMOTE_IO_SERVER), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.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 const&, int&&, String const&, unsigned long&&, String const&) @ 0x000000000feda8d9 4. /build/src/IO/HTTPCommon.cpp:104: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x000000000feda6e2 5. /build/src/IO/HTTPCommon.cpp:93: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x000000000feda537 6. /build/src/IO/ReadWriteBufferFromHTTP.cpp:277: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x000000001184a4c4 7. /build/src/IO/ReadWriteBufferFromHTTP.cpp:285: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x000000001184a615 8. /build/src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x000000001184ae59 9. /build/src/IO/ReadWriteBufferFromHTTP.cpp:472: void std::__function::__policy_invoker::__call_impl[abi:se190107]>(std::__function::__policy_storage const*) @ 0x000000001184cedd 10. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001184858b 11. /build/src/IO/ReadWriteBufferFromHTTP.cpp:465: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x000000001184bf0b 12. /build/src/IO/ReadBuffer.h:60: DB::ReadBuffer::next() @ 0x000000000a148c7b 13. /build/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) @ 0x0000000011849fb2 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]>&)>&, 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&) @ 0x0000000011841980 15. /build/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) @ 0x000000001621208e 16. /build/src/Storages/StorageReplicatedMergeTree.cpp:5228: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl[abi:se190107] const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000015f9a5fe 17. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000015ed8bfd 18. /build/src/Storages/StorageReplicatedMergeTree.cpp:2514: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x0000000015ec9aab 19. /build/src/Storages/StorageReplicatedMergeTree.cpp:2349: DB::StorageReplicatedMergeTree::executeLogEntry(DB::ReplicatedMergeTreeLogEntry&) @ 0x0000000015eba91b 20. /build/src/Storages/StorageReplicatedMergeTree.cpp:3876: bool std::__function::__policy_invoker&)>::__call_impl[abi:se190107])::$_1, bool (std::shared_ptr&)>>(std::__function::__policy_storage const*, std::shared_ptr&) @ 0x0000000015f9837e 21. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000165d6fc3 22. /build/src/Storages/StorageReplicatedMergeTree.cpp:3872: DB::StorageReplicatedMergeTree::processQueueEntry(std::shared_ptr) @ 0x0000000015efc18a 23. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001624c1b2 24. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000162f9c70 25. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x00000000162fa55a 26. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc6653 27. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000000fccc4c3 28. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc3d92 29. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fcca080 30. ? @ 0x00007fbc6213eac3 31. ? @ 0x00007fbc621d0850 (version 25.3.6.10636.altinitytest (altinity build)) 2025.07.28 11:53:21.171896 [ 5112 ] {} TCPHandler: Code: 407. DB::Exception: Decimal math overflow: while executing 'FUNCTION plus(__table1.e : 0, 21_UInt8 : 1) -> plus(__table1.e, 21_UInt8) Decimal(18, 18) : 4'. (DECIMAL_OVERFLOW), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000000a074fcb 4. /build/src/Functions/FunctionBinaryArithmetic.h:763: void DB::impl_::DecimalBinaryOperation, true>::process<(DB::impl_::OpCase)2, true, false, DB::PODArray, 4096ul, Allocator, 63ul, 64ul>, long>(DB::PODArray, 4096ul, Allocator, 63ul, 64ul> const&, long const&, DB::PODArray, 4096ul, Allocator, 63ul, 64ul>&, long, long, DB::PODArray, 63ul, 64ul> const*) @ 0x000000000df0bd17 5. /build/src/Functions/FunctionBinaryArithmetic.h:1485: COW::immutable_ptr DB::FunctionBinaryArithmetic::executeNumericWithDecimal>, DB::DataTypeNumber, DB::DataTypeDecimal>, DB::DataTypeDecimal>, DB::DataTypeNumber, DB::ColumnDecimal>, DB::ColumnVector>(DB::DataTypeDecimal> const&, DB::DataTypeNumber const&, DB::ColumnConst const*, DB::ColumnConst const*, DB::ColumnDecimal> const*, DB::ColumnVector const*, unsigned long, DB::PODArray, 63ul, 64ul> const*) const @ 0x000000000dffd6de 6. /build/src/Functions/FunctionBinaryArithmetic.h:2270: COW::immutable_ptr DB::FunctionBinaryArithmetic::executeNumeric>, DB::DataTypeNumber>(std::vector> const&, DB::DataTypeDecimal> const&, DB::DataTypeNumber const&, DB::PODArray, 63ul, 64ul> const*) const @ 0x000000000dffd264 7. /build/src/Functions/FunctionBinaryArithmetic.h:2508: 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&&) @ 0x000000000dffc170 8. /build/src/Functions/FunctionBinaryArithmetic.h:846: 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&&) @ 0x000000000df74c83 9. /build/src/Functions/FunctionBinaryArithmetic.h:844: DB::FunctionBinaryArithmetic::executeImpl2(std::vector> const&, std::shared_ptr const&, unsigned long, DB::PODArray, 63ul, 64ul> const*) const @ 0x000000000df70b05 10. /build/src/Functions/FunctionBinaryArithmetic.h:2410: DB::FunctionBinaryArithmetic::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000df6e798 11. /build/src/Functions/FunctionBinaryArithmetic.h:2645: DB::FunctionBinaryArithmeticWithConstants::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000df6d494 12. /build/src/Functions/IFunctionAdaptors.cpp:10: DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000012d995fa 13. /build/src/Functions/IFunction.cpp:353: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d93b52 14. /build/src/Functions/IFunction.cpp:420: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d95059 15. /build/src/Functions/IFunction.cpp:498: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d95c72 16. /build/src/Interpreters/ExpressionActions.cpp:636: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x00000000145176f3 17. /build/src/Processors/Transforms/ExpressionTransform.cpp:25: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x0000000016c0b34c 18. /build/src/Processors/ISimpleTransform.h:33: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000011a9a453 19. /build/src/Processors/ISimpleTransform.cpp:89: DB::ISimpleTransform::work() @ 0x000000001699fca0 20. /build/src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x00000000169bd00f 21. /build/src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x00000000169b2105 22. /build/src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeSingleThread(unsigned long) @ 0x00000000169b23be 23. /build/src/Processors/Executors/PipelineExecutor.cpp:416: void std::__function::__policy_invoker::__call_impl[abi:se190107]>(std::__function::__policy_storage const*) @ 0x00000000169b2e3f 24. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc6653 25. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000000fccc4c3 26. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc3d92 27. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fcca080 28. ? @ 0x00007fbc6213eac3 29. ? @ 0x00007fbc621d0850 Job's origin stack trace: 0. /build/src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000000fc33b84 1. /build/src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000000fcc2ea7 2. /build/src/Common/ThreadPool.cpp:401: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fcc7f1c 3. /build/src/Common/ThreadPool.cpp:494: ThreadPoolImpl>::scheduleOrThrowOnError(std::function, Priority) @ 0x000000000fcc7a0e 4. /build/src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::spawnThreadsImpl() @ 0x00000000169b2c0c 5. /build/src/Processors/Executors/PipelineExecutor.cpp:394: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x00000000169b0ba7 6. /build/src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x00000000169b03f4 7. /build/src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:se190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169bfeab 8. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc3d92 9. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fcca080 10. ? @ 0x00007fbc6213eac3 11. ? @ 0x00007fbc621d0850 Job's origin stack trace: 0. /build/src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000000fc33b84 1. /build/src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000000fcc2ea7 2. /build/src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fcc535c 3. /build/src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000000fcc584d 4. /build/src/Common/ThreadPool.h:279: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x00000000169bf193 5. /build/src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x00000000169bf518 6. /build/src/Server/TCPHandler.cpp:1237: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x00000000168f1525 7. /build/src/Server/TCPHandler.cpp:678: DB::TCPHandler::runImpl() @ 0x00000000168e68e5 8. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 9. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 10. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 11. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 12. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 13. ? @ 0x00007fbc6213eac3 14. ? @ 0x00007fbc621d0850 2025.07.28 11:53:21.206320 [ 17207 ] {} TCPHandler: Code: 676. DB::Exception: Cannot parse IPv6 test: Cannot parse IPv6 from String: In scope SELECT toIPv6('test'). (CANNOT_PARSE_IPV6), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl>>::type>, std::basic_string_view>&&) @ 0x000000000a119c0b 4. /build/src/IO/ReadHelpers.h:993: COW::immutable_ptr DB::detail::ConvertThroughParsing::execute(std::vector> const&, std::shared_ptr const&, unsigned long, void*) @ 0x00000000130e0614 5. /build/src/Functions/FunctionsConversion.h:1580: COW::immutable_ptr DB::detail::ConvertImpl::execute(std::vector> const&, std::shared_ptr const&, unsigned long, DB::detail::BehaviourOnErrorFromString, void*) @ 0x00000000130e021e 6. /build/src/Functions/FunctionsConversion.h:2472: 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&&) @ 0x0000000012fab964 7. /build/src/Functions/FunctionsConversion.h:2527: DB::detail::FunctionConvert>>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000012fc9e94 8. /build/src/Functions/FunctionsConversion.h:2307: DB::detail::FunctionConvert>>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000012fc965a 9. /build/src/Functions/IFunction.h:437: DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000a069f2a 10. /build/src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000012d9965a 11. /build/src/Functions/IFunction.cpp:351: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d93b02 12. /build/src/Functions/IFunction.cpp:177: DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d93698 13. /build/src/Functions/IFunction.cpp:343: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d93aad 14. /build/src/Functions/IFunction.cpp:420: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d95059 15. /build/src/Functions/IFunction.cpp:498: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d95c72 16. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3567: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000014034494 17. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3838: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000014019a9e 18. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3980: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000014018e31 19. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:4304: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000014042fa7 20. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5605: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000014013749 21. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000140127f9 22. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000014011fce 23. /build/src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000001406ce8a 24. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000014973b42 25. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000001497268d 26. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000014974d24 27. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001492924b 28. /build/src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88641 29. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 30. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 31. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 2025.07.28 11:53:21.562073 [ 3960 ] {} test_13.rmt2 (7f9b740d-015c-470e-8cc6-8ba33be0dc63): auto DB::StorageReplicatedMergeTree::processQueueEntry(ReplicatedMergeTreeQueue::SelectedEntryPtr)::(anonymous class)::operator()(LogEntryPtr &) const: Code: 86. DB::HTTPException: Received error from remote server http://146b4357c08d:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Ftest%2F01165%2Ftest_13%2Frmt%2Freplicas%2F1&part=20250728_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.6.10636.altinitytest (altinity build)) '. (RECEIVED_ERROR_FROM_REMOTE_IO_SERVER), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.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 const&, int&&, String const&, unsigned long&&, String const&) @ 0x000000000feda8d9 4. /build/src/IO/HTTPCommon.cpp:104: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x000000000feda6e2 5. /build/src/IO/HTTPCommon.cpp:93: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x000000000feda537 6. /build/src/IO/ReadWriteBufferFromHTTP.cpp:277: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x000000001184a4c4 7. /build/src/IO/ReadWriteBufferFromHTTP.cpp:285: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x000000001184a615 8. /build/src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x000000001184ae59 9. /build/src/IO/ReadWriteBufferFromHTTP.cpp:472: void std::__function::__policy_invoker::__call_impl[abi:se190107]>(std::__function::__policy_storage const*) @ 0x000000001184cedd 10. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001184858b 11. /build/src/IO/ReadWriteBufferFromHTTP.cpp:465: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x000000001184bf0b 12. /build/src/IO/ReadBuffer.h:60: DB::ReadBuffer::next() @ 0x000000000a148c7b 13. /build/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) @ 0x0000000011849fb2 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]>&)>&, 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&) @ 0x0000000011841980 15. /build/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) @ 0x000000001621208e 16. /build/src/Storages/StorageReplicatedMergeTree.cpp:5228: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl[abi:se190107] const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000015f9a5fe 17. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000015ed8bfd 18. /build/src/Storages/StorageReplicatedMergeTree.cpp:2514: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x0000000015ec9aab 19. /build/src/Storages/StorageReplicatedMergeTree.cpp:2349: DB::StorageReplicatedMergeTree::executeLogEntry(DB::ReplicatedMergeTreeLogEntry&) @ 0x0000000015eba91b 20. /build/src/Storages/StorageReplicatedMergeTree.cpp:3876: bool std::__function::__policy_invoker&)>::__call_impl[abi:se190107])::$_1, bool (std::shared_ptr&)>>(std::__function::__policy_storage const*, std::shared_ptr&) @ 0x0000000015f9837e 21. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000165d6fc3 22. /build/src/Storages/StorageReplicatedMergeTree.cpp:3872: DB::StorageReplicatedMergeTree::processQueueEntry(std::shared_ptr) @ 0x0000000015efc18a 23. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001624c1b2 24. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000162f9c70 25. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x00000000162fa55a 26. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc6653 27. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000000fccc4c3 28. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc3d92 29. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fcca080 30. ? @ 0x00007fbc6213eac3 31. ? @ 0x00007fbc621d0850 (version 25.3.6.10636.altinitytest (altinity build)) 2025.07.28 11:53:21.611349 [ 17611 ] {} 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. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception>&, String>(int, FormatStringHelperImpl>&>::type, std::type_identity::type>, std::basic_string_view>&, String&&) @ 0x000000001385a5eb 4. /build/src/Access/SettingsConstraints.cpp:376: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000013859b18 5. /build/src/Access/SettingsConstraints.cpp:300: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000013858faf 6. /build/src/Access/SettingsConstraints.cpp:209: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000013859223 7. /build/src/Interpreters/Context.cpp:2690: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000014436134 8. /build/src/Interpreters/Context.cpp:2729: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x000000001443662b 9. /build/src/Server/HTTPHandler.cpp:457: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000001686d165 10. /build/src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x0000000016870807 11. /build/src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x0000000016907e99 12. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 13. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 14. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 15. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 16. ? @ 0x00007fbc6213eac3 17. ? @ 0x00007fbc621d0850 (version 25.3.6.10636.altinitytest (altinity build)) 2025.07.28 11:53:21.806433 [ 17207 ] {67782ab1-e14b-4451-9536-213ae2369688} executeQuery: Code: 676. DB::Exception: Cannot parse IPv6 .1.2.3: Cannot parse IPv6 from String: In scope SELECT toIPv6('::.1.2.3'). (CANNOT_PARSE_IPV6) (version 25.3.6.10636.altinitytest (altinity build)) (from [::1]:48582) (comment: 02234_cast_to_ip_address.sql) (query 46, line 66) (in query: SELECT toIPv6('::.1.2.3');), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl>>::type>, std::basic_string_view>&&) @ 0x000000000a119c0b 4. /build/src/IO/ReadHelpers.h:993: COW::immutable_ptr DB::detail::ConvertThroughParsing::execute(std::vector> const&, std::shared_ptr const&, unsigned long, void*) @ 0x00000000130e0614 5. /build/src/Functions/FunctionsConversion.h:1580: COW::immutable_ptr DB::detail::ConvertImpl::execute(std::vector> const&, std::shared_ptr const&, unsigned long, DB::detail::BehaviourOnErrorFromString, void*) @ 0x00000000130e021e 6. /build/src/Functions/FunctionsConversion.h:2472: 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&&) @ 0x0000000012fab964 7. /build/src/Functions/FunctionsConversion.h:2527: DB::detail::FunctionConvert>>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000012fc9e94 8. /build/src/Functions/FunctionsConversion.h:2307: DB::detail::FunctionConvert>>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000012fc965a 9. /build/src/Functions/IFunction.h:437: DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000a069f2a 10. /build/src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000012d9965a 11. /build/src/Functions/IFunction.cpp:351: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d93b02 12. /build/src/Functions/IFunction.cpp:177: DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d93698 13. /build/src/Functions/IFunction.cpp:343: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d93aad 14. /build/src/Functions/IFunction.cpp:420: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d95059 15. /build/src/Functions/IFunction.cpp:498: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d95c72 16. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3567: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000014034494 17. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3838: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000014019a9e 18. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3980: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000014018e31 19. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:4304: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000014042fa7 20. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5605: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000014013749 21. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000140127f9 22. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000014011fce 23. /build/src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000001406ce8a 24. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000014973b42 25. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000001497268d 26. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000014974d24 27. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001492924b 28. /build/src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88641 29. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 30. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 31. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 2025.07.28 11:53:21.810246 [ 17207 ] {} TCPHandler: Code: 676. DB::Exception: Cannot parse IPv6 .1.2.3: Cannot parse IPv6 from String: In scope SELECT toIPv6('::.1.2.3'). (CANNOT_PARSE_IPV6), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl>>::type>, std::basic_string_view>&&) @ 0x000000000a119c0b 4. /build/src/IO/ReadHelpers.h:993: COW::immutable_ptr DB::detail::ConvertThroughParsing::execute(std::vector> const&, std::shared_ptr const&, unsigned long, void*) @ 0x00000000130e0614 5. /build/src/Functions/FunctionsConversion.h:1580: COW::immutable_ptr DB::detail::ConvertImpl::execute(std::vector> const&, std::shared_ptr const&, unsigned long, DB::detail::BehaviourOnErrorFromString, void*) @ 0x00000000130e021e 6. /build/src/Functions/FunctionsConversion.h:2472: 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&&) @ 0x0000000012fab964 7. /build/src/Functions/FunctionsConversion.h:2527: DB::detail::FunctionConvert>>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000012fc9e94 8. /build/src/Functions/FunctionsConversion.h:2307: DB::detail::FunctionConvert>>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000012fc965a 9. /build/src/Functions/IFunction.h:437: DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000a069f2a 10. /build/src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000012d9965a 11. /build/src/Functions/IFunction.cpp:351: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d93b02 12. /build/src/Functions/IFunction.cpp:177: DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d93698 13. /build/src/Functions/IFunction.cpp:343: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d93aad 14. /build/src/Functions/IFunction.cpp:420: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d95059 15. /build/src/Functions/IFunction.cpp:498: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d95c72 16. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3567: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000014034494 17. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3838: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000014019a9e 18. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3980: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000014018e31 19. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:4304: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000014042fa7 20. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5605: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000014013749 21. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000140127f9 22. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000014011fce 23. /build/src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000001406ce8a 24. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000014973b42 25. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000001497268d 26. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000014974d24 27. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001492924b 28. /build/src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88641 29. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 30. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 31. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 2025.07.28 11:53:22.038968 [ 3961 ] {} test_13.rmt2 (7f9b740d-015c-470e-8cc6-8ba33be0dc63): auto DB::StorageReplicatedMergeTree::processQueueEntry(ReplicatedMergeTreeQueue::SelectedEntryPtr)::(anonymous class)::operator()(LogEntryPtr &) const: Code: 86. DB::HTTPException: Received error from remote server http://146b4357c08d:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Ftest%2F01165%2Ftest_13%2Frmt%2Freplicas%2F1&part=20250728_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.6.10636.altinitytest (altinity build)) '. (RECEIVED_ERROR_FROM_REMOTE_IO_SERVER), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.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 const&, int&&, String const&, unsigned long&&, String const&) @ 0x000000000feda8d9 4. /build/src/IO/HTTPCommon.cpp:104: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x000000000feda6e2 5. /build/src/IO/HTTPCommon.cpp:93: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x000000000feda537 6. /build/src/IO/ReadWriteBufferFromHTTP.cpp:277: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x000000001184a4c4 7. /build/src/IO/ReadWriteBufferFromHTTP.cpp:285: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x000000001184a615 8. /build/src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x000000001184ae59 9. /build/src/IO/ReadWriteBufferFromHTTP.cpp:472: void std::__function::__policy_invoker::__call_impl[abi:se190107]>(std::__function::__policy_storage const*) @ 0x000000001184cedd 10. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001184858b 11. /build/src/IO/ReadWriteBufferFromHTTP.cpp:465: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x000000001184bf0b 12. /build/src/IO/ReadBuffer.h:60: DB::ReadBuffer::next() @ 0x000000000a148c7b 13. /build/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) @ 0x0000000011849fb2 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]>&)>&, 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&) @ 0x0000000011841980 15. /build/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) @ 0x000000001621208e 16. /build/src/Storages/StorageReplicatedMergeTree.cpp:5228: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl[abi:se190107] const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000015f9a5fe 17. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000015ed8bfd 18. /build/src/Storages/StorageReplicatedMergeTree.cpp:2514: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x0000000015ec9aab 19. /build/src/Storages/StorageReplicatedMergeTree.cpp:2349: DB::StorageReplicatedMergeTree::executeLogEntry(DB::ReplicatedMergeTreeLogEntry&) @ 0x0000000015eba91b 20. /build/src/Storages/StorageReplicatedMergeTree.cpp:3876: bool std::__function::__policy_invoker&)>::__call_impl[abi:se190107])::$_1, bool (std::shared_ptr&)>>(std::__function::__policy_storage const*, std::shared_ptr&) @ 0x0000000015f9837e 21. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000165d6fc3 22. /build/src/Storages/StorageReplicatedMergeTree.cpp:3872: DB::StorageReplicatedMergeTree::processQueueEntry(std::shared_ptr) @ 0x0000000015efc18a 23. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001624c1b2 24. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000162f9c70 25. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x00000000162fa55a 26. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc6653 27. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000000fccc4c3 28. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc3d92 29. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fcca080 30. ? @ 0x00007fbc6213eac3 31. ? @ 0x00007fbc621d0850 (version 25.3.6.10636.altinitytest (altinity build)) 2025.07.28 11:53:22.267119 [ 4280 ] {} virtual void DB::ServerAsynchronousMetrics::updateImpl(TimePoint, TimePoint, bool, bool, AsynchronousMetricValues &): Cannot get replica delay for table: test_h1z9vtov.enum_alter_issue: Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_h1z9vtov/test_02012/enum_alter_issue/replicas/r2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000a9b78ab 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:5935: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000015e86144 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:7510: DB::StorageReplicatedMergeTree::getReplicaDelays(long&, long&) @ 0x0000000015f460bf 6. /build/src/Interpreters/ServerAsynchronousMetrics.cpp:374: DB::ServerAsynchronousMetrics::updateImpl(std::chrono::time_point>>, std::chrono::time_point>>, bool, bool, std::unordered_map, std::equal_to, std::allocator>>&) @ 0x0000000014a6793d 7. /build/src/Common/AsynchronousMetrics.cpp:1850: DB::AsynchronousMetrics::update(std::chrono::time_point>>, bool) @ 0x000000000fd34ea4 8. /build/src/Common/AsynchronousMetrics.cpp:391: DB::AsynchronousMetrics::run() @ 0x000000000fd36099 9. /build/src/Common/AsynchronousMetrics.cpp:299: void std::__function::__policy_invoker::__call_impl[abi:se190107]::ThreadFromGlobalPoolImpl(DB::AsynchronousMetrics::start()::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000000fd381ca 10. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc3d92 11. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fcca080 12. ? @ 0x00007fbc6213eac3 13. ? @ 0x00007fbc621d0850 (version 25.3.6.10636.altinitytest (altinity build)) 2025.07.28 11:53:22.419517 [ 5112 ] {240de354-c9d9-42ac-be67-2f1a383ba65f} executeQuery: Code: 407. DB::Exception: Decimal math overflow: while executing 'FUNCTION plus(21_UInt8 : 1, __table1.e : 0) -> plus(21_UInt8, __table1.e) Decimal(18, 18) : 4'. (DECIMAL_OVERFLOW) (version 25.3.6.10636.altinitytest (altinity build)) (from [::1]:48688) (comment: 00700_decimal_arithm.sql) (query 29, line 51) (in query: SELECT 21 + e, 21 - e, 84 - e, 21 * e, -21 * e, 21 / e, 84 / e FROM decimal WHERE e > 0;), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000000a074fcb 4. /build/src/Functions/FunctionBinaryArithmetic.h:763: void DB::impl_::DecimalBinaryOperation, true>::process<(DB::impl_::OpCase)1, false, true, long, DB::PODArray, 4096ul, Allocator, 63ul, 64ul>>(long const&, DB::PODArray, 4096ul, Allocator, 63ul, 64ul> const&, DB::PODArray, 4096ul, Allocator, 63ul, 64ul>&, long, long, DB::PODArray, 63ul, 64ul> const*) @ 0x000000000de97361 5. /build/src/Functions/FunctionBinaryArithmetic.h:1485: COW::immutable_ptr DB::FunctionBinaryArithmetic::executeNumericWithDecimal, DB::DataTypeDecimal>, DB::DataTypeDecimal>, DB::DataTypeNumber, DB::DataTypeDecimal>, DB::ColumnVector, DB::ColumnDecimal>>(DB::DataTypeNumber const&, DB::DataTypeDecimal> const&, DB::ColumnConst const*, DB::ColumnConst const*, DB::ColumnVector const*, DB::ColumnDecimal> const*, unsigned long, DB::PODArray, 63ul, 64ul> const*) const @ 0x000000000df7bb6b 6. /build/src/Functions/FunctionBinaryArithmetic.h:2270: COW::immutable_ptr DB::FunctionBinaryArithmetic::executeNumeric, DB::DataTypeDecimal>>(std::vector> const&, DB::DataTypeNumber const&, DB::DataTypeDecimal> const&, DB::PODArray, 63ul, 64ul> const*) const @ 0x000000000df7b7c4 7. /build/src/Functions/FunctionBinaryArithmetic.h:2508: auto auto bool DB::FunctionBinaryArithmetic::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&)::operator()>>(auto const&) const @ 0x000000000df75c67 8. /build/src/Functions/castTypeToEither.h:18: 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&&) @ 0x000000000df757b0 9. /build/src/Functions/FunctionBinaryArithmetic.h:846: 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&&) @ 0x000000000df74607 10. /build/src/Functions/FunctionBinaryArithmetic.h:844: DB::FunctionBinaryArithmetic::executeImpl2(std::vector> const&, std::shared_ptr const&, unsigned long, DB::PODArray, 63ul, 64ul> const*) const @ 0x000000000df70b05 11. /build/src/Functions/FunctionBinaryArithmetic.h:2410: DB::FunctionBinaryArithmetic::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000df6e798 12. /build/src/Functions/FunctionBinaryArithmetic.h:2645: DB::FunctionBinaryArithmeticWithConstants::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000df6d494 13. /build/src/Functions/IFunctionAdaptors.cpp:10: DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000012d995fa 14. /build/src/Functions/IFunction.cpp:353: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d93b52 15. /build/src/Functions/IFunction.cpp:420: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d95059 16. /build/src/Functions/IFunction.cpp:498: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d95c72 17. /build/src/Interpreters/ExpressionActions.cpp:636: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x00000000145176f3 18. /build/src/Processors/Transforms/ExpressionTransform.cpp:25: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x0000000016c0b34c 19. /build/src/Processors/ISimpleTransform.h:33: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000011a9a453 20. /build/src/Processors/ISimpleTransform.cpp:89: DB::ISimpleTransform::work() @ 0x000000001699fca0 21. /build/src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x00000000169bd00f 22. /build/src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x00000000169b2105 23. /build/src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeSingleThread(unsigned long) @ 0x00000000169b23be 24. /build/src/Processors/Executors/PipelineExecutor.cpp:416: void std::__function::__policy_invoker::__call_impl[abi:se190107]>(std::__function::__policy_storage const*) @ 0x00000000169b2e3f 25. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc6653 26. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000000fccc4c3 27. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc3d92 28. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fcca080 29. ? @ 0x00007fbc6213eac3 30. ? @ 0x00007fbc621d0850 2025.07.28 11:53:22.425078 [ 17371 ] {1ea867d0-b829-4d39-b81f-71a6d332a391} executeQuery: Code: 43. DB::Exception: Argument 'max_width' must not be NaN: In scope SELECT bar((greatCircleAngle(65537, 2, 1, 1) - 1) * 65535, 1048576, 1048577, nan). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.6.10636.altinitytest (altinity build)) (from [::1]:51078) (comment: 01621_bar_nan_arguments.sql) (query 1, line 1) (in query: SELECT bar((greatCircleAngle(65537, 2, 1, 1) - 1) * 65535, 1048576, 1048577, nan);), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000000a074fcb 4. /build/src/Functions/bar.cpp:91: DB::(anonymous namespace)::FunctionBar::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000aad93b9 5. /build/src/Functions/IFunction.h:437: DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000a069f2a 6. /build/src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000012d9965a 7. /build/src/Functions/IFunction.cpp:351: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d93b02 8. /build/src/Functions/IFunction.cpp:177: DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d93698 9. /build/src/Functions/IFunction.cpp:343: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d93aad 10. /build/src/Functions/IFunction.cpp:420: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d95059 11. /build/src/Functions/IFunction.cpp:498: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d95c72 12. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3567: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000014034494 13. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3838: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000014019a9e 14. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3980: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000014018e31 15. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:4304: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000014042fa7 16. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5605: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000014013749 17. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000140127f9 18. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000014011fce 19. /build/src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000001406ce8a 20. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000014973b42 21. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000001497268d 22. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000014974d24 23. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001492924b 24. /build/src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88641 25. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 26. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 27. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 28. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 29. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 30. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 31. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 2025.07.28 11:53:22.444156 [ 17371 ] {} TCPHandler: Code: 43. DB::Exception: Argument 'max_width' must not be NaN: In scope SELECT bar((greatCircleAngle(65537, 2, 1, 1) - 1) * 65535, 1048576, 1048577, nan). (ILLEGAL_TYPE_OF_ARGUMENT), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000000a074fcb 4. /build/src/Functions/bar.cpp:91: DB::(anonymous namespace)::FunctionBar::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000aad93b9 5. /build/src/Functions/IFunction.h:437: DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000a069f2a 6. /build/src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000012d9965a 7. /build/src/Functions/IFunction.cpp:351: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d93b02 8. /build/src/Functions/IFunction.cpp:177: DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d93698 9. /build/src/Functions/IFunction.cpp:343: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d93aad 10. /build/src/Functions/IFunction.cpp:420: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d95059 11. /build/src/Functions/IFunction.cpp:498: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d95c72 12. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3567: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000014034494 13. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3838: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000014019a9e 14. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3980: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000014018e31 15. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:4304: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000014042fa7 16. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5605: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000014013749 17. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000140127f9 18. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000014011fce 19. /build/src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000001406ce8a 20. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000014973b42 21. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000001497268d 22. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000014974d24 23. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001492924b 24. /build/src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88641 25. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 26. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 27. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 28. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 29. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 30. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 31. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 2025.07.28 11:53:22.455627 [ 5112 ] {} TCPHandler: Code: 407. DB::Exception: Decimal math overflow: while executing 'FUNCTION plus(21_UInt8 : 1, __table1.e : 0) -> plus(21_UInt8, __table1.e) Decimal(18, 18) : 4'. (DECIMAL_OVERFLOW), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000000a074fcb 4. /build/src/Functions/FunctionBinaryArithmetic.h:763: void DB::impl_::DecimalBinaryOperation, true>::process<(DB::impl_::OpCase)1, false, true, long, DB::PODArray, 4096ul, Allocator, 63ul, 64ul>>(long const&, DB::PODArray, 4096ul, Allocator, 63ul, 64ul> const&, DB::PODArray, 4096ul, Allocator, 63ul, 64ul>&, long, long, DB::PODArray, 63ul, 64ul> const*) @ 0x000000000de97361 5. /build/src/Functions/FunctionBinaryArithmetic.h:1485: COW::immutable_ptr DB::FunctionBinaryArithmetic::executeNumericWithDecimal, DB::DataTypeDecimal>, DB::DataTypeDecimal>, DB::DataTypeNumber, DB::DataTypeDecimal>, DB::ColumnVector, DB::ColumnDecimal>>(DB::DataTypeNumber const&, DB::DataTypeDecimal> const&, DB::ColumnConst const*, DB::ColumnConst const*, DB::ColumnVector const*, DB::ColumnDecimal> const*, unsigned long, DB::PODArray, 63ul, 64ul> const*) const @ 0x000000000df7bb6b 6. /build/src/Functions/FunctionBinaryArithmetic.h:2270: COW::immutable_ptr DB::FunctionBinaryArithmetic::executeNumeric, DB::DataTypeDecimal>>(std::vector> const&, DB::DataTypeNumber const&, DB::DataTypeDecimal> const&, DB::PODArray, 63ul, 64ul> const*) const @ 0x000000000df7b7c4 7. /build/src/Functions/FunctionBinaryArithmetic.h:2508: auto auto bool DB::FunctionBinaryArithmetic::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&)::operator()>>(auto const&) const @ 0x000000000df75c67 8. /build/src/Functions/castTypeToEither.h:18: 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&&) @ 0x000000000df757b0 9. /build/src/Functions/FunctionBinaryArithmetic.h:846: 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&&) @ 0x000000000df74607 10. /build/src/Functions/FunctionBinaryArithmetic.h:844: DB::FunctionBinaryArithmetic::executeImpl2(std::vector> const&, std::shared_ptr const&, unsigned long, DB::PODArray, 63ul, 64ul> const*) const @ 0x000000000df70b05 11. /build/src/Functions/FunctionBinaryArithmetic.h:2410: DB::FunctionBinaryArithmetic::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000df6e798 12. /build/src/Functions/FunctionBinaryArithmetic.h:2645: DB::FunctionBinaryArithmeticWithConstants::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000df6d494 13. /build/src/Functions/IFunctionAdaptors.cpp:10: DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000012d995fa 14. /build/src/Functions/IFunction.cpp:353: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d93b52 15. /build/src/Functions/IFunction.cpp:420: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d95059 16. /build/src/Functions/IFunction.cpp:498: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d95c72 17. /build/src/Interpreters/ExpressionActions.cpp:636: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x00000000145176f3 18. /build/src/Processors/Transforms/ExpressionTransform.cpp:25: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x0000000016c0b34c 19. /build/src/Processors/ISimpleTransform.h:33: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000011a9a453 20. /build/src/Processors/ISimpleTransform.cpp:89: DB::ISimpleTransform::work() @ 0x000000001699fca0 21. /build/src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x00000000169bd00f 22. /build/src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x00000000169b2105 23. /build/src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeSingleThread(unsigned long) @ 0x00000000169b23be 24. /build/src/Processors/Executors/PipelineExecutor.cpp:416: void std::__function::__policy_invoker::__call_impl[abi:se190107]>(std::__function::__policy_storage const*) @ 0x00000000169b2e3f 25. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc6653 26. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000000fccc4c3 27. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc3d92 28. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fcca080 29. ? @ 0x00007fbc6213eac3 30. ? @ 0x00007fbc621d0850 Job's origin stack trace: 0. /build/src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000000fc33b84 1. /build/src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000000fcc2ea7 2. /build/src/Common/ThreadPool.cpp:401: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fcc7f1c 3. /build/src/Common/ThreadPool.cpp:494: ThreadPoolImpl>::scheduleOrThrowOnError(std::function, Priority) @ 0x000000000fcc7a0e 4. /build/src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::spawnThreadsImpl() @ 0x00000000169b2c0c 5. /build/src/Processors/Executors/PipelineExecutor.cpp:394: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x00000000169b0ba7 6. /build/src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x00000000169b03f4 7. /build/src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:se190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169bfeab 8. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc3d92 9. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fcca080 10. ? @ 0x00007fbc6213eac3 11. ? @ 0x00007fbc621d0850 Job's origin stack trace: 0. /build/src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000000fc33b84 1. /build/src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000000fcc2ea7 2. /build/src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fcc535c 3. /build/src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000000fcc584d 4. /build/src/Common/ThreadPool.h:279: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x00000000169bf193 5. /build/src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x00000000169bf518 6. /build/src/Server/TCPHandler.cpp:1237: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x00000000168f1525 7. /build/src/Server/TCPHandler.cpp:678: DB::TCPHandler::runImpl() @ 0x00000000168e68e5 8. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 9. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 10. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 11. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 12. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 13. ? @ 0x00007fbc6213eac3 14. ? @ 0x00007fbc621d0850 2025.07.28 11:53:22.540220 [ 17371 ] {58e2f8a7-5a8b-4797-a77c-be77c1528e59} executeQuery: Code: 43. DB::Exception: Argument 'max_width' must not be NaN: In scope SELECT bar(1, 1, 1, nan). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.6.10636.altinitytest (altinity build)) (from [::1]:51078) (comment: 01621_bar_nan_arguments.sql) (query 2, line 2) (in query: select bar(1,1,1,nan);), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000000a074fcb 4. /build/src/Functions/bar.cpp:91: DB::(anonymous namespace)::FunctionBar::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000aad93b9 5. /build/src/Functions/IFunction.h:437: DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000a069f2a 6. /build/src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000012d9965a 7. /build/src/Functions/IFunction.cpp:351: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d93b02 8. /build/src/Functions/IFunction.cpp:177: DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d93698 9. /build/src/Functions/IFunction.cpp:343: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d93aad 10. /build/src/Functions/IFunction.cpp:420: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d95059 11. /build/src/Functions/IFunction.cpp:498: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d95c72 12. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3567: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000014034494 13. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3838: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000014019a9e 14. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3980: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000014018e31 15. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:4304: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000014042fa7 16. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5605: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000014013749 17. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000140127f9 18. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000014011fce 19. /build/src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000001406ce8a 20. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000014973b42 21. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000001497268d 22. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000014974d24 23. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001492924b 24. /build/src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88641 25. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 26. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 27. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 28. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 29. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 30. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 31. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 2025.07.28 11:53:22.543994 [ 17371 ] {} TCPHandler: Code: 43. DB::Exception: Argument 'max_width' must not be NaN: In scope SELECT bar(1, 1, 1, nan). (ILLEGAL_TYPE_OF_ARGUMENT), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000000a074fcb 4. /build/src/Functions/bar.cpp:91: DB::(anonymous namespace)::FunctionBar::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000aad93b9 5. /build/src/Functions/IFunction.h:437: DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000a069f2a 6. /build/src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000012d9965a 7. /build/src/Functions/IFunction.cpp:351: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d93b02 8. /build/src/Functions/IFunction.cpp:177: DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d93698 9. /build/src/Functions/IFunction.cpp:343: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d93aad 10. /build/src/Functions/IFunction.cpp:420: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d95059 11. /build/src/Functions/IFunction.cpp:498: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d95c72 12. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3567: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000014034494 13. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3838: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000014019a9e 14. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3980: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000014018e31 15. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:4304: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000014042fa7 16. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5605: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000014013749 17. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000140127f9 18. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000014011fce 19. /build/src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000001406ce8a 20. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000014973b42 21. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000001497268d 22. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000014974d24 23. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001492924b 24. /build/src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88641 25. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 26. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 27. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 28. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 29. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 30. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 31. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 2025.07.28 11:53:22.723822 [ 17611 ] {} 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. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception>&, String>(int, FormatStringHelperImpl>&>::type, std::type_identity::type>, std::basic_string_view>&, String&&) @ 0x000000001385a5eb 4. /build/src/Access/SettingsConstraints.cpp:376: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000013859b18 5. /build/src/Access/SettingsConstraints.cpp:300: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000013858faf 6. /build/src/Access/SettingsConstraints.cpp:209: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000013859223 7. /build/src/Interpreters/Context.cpp:2690: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000014436134 8. /build/src/Interpreters/Context.cpp:2729: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x000000001443662b 9. /build/src/Server/HTTPHandler.cpp:457: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000001686d165 10. /build/src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x0000000016870807 11. /build/src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x0000000016907e99 12. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 13. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 14. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 15. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 16. ? @ 0x00007fbc6213eac3 17. ? @ 0x00007fbc621d0850 (version 25.3.6.10636.altinitytest (altinity build)) 2025.07.28 11:53:23.178296 [ 3964 ] {} test_13.rmt2 (7f9b740d-015c-470e-8cc6-8ba33be0dc63): auto DB::StorageReplicatedMergeTree::processQueueEntry(ReplicatedMergeTreeQueue::SelectedEntryPtr)::(anonymous class)::operator()(LogEntryPtr &) const: Code: 86. DB::HTTPException: Received error from remote server http://146b4357c08d:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Ftest%2F01165%2Ftest_13%2Frmt%2Freplicas%2F1&part=20250728_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.6.10636.altinitytest (altinity build)) '. (RECEIVED_ERROR_FROM_REMOTE_IO_SERVER), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.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 const&, int&&, String const&, unsigned long&&, String const&) @ 0x000000000feda8d9 4. /build/src/IO/HTTPCommon.cpp:104: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x000000000feda6e2 5. /build/src/IO/HTTPCommon.cpp:93: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x000000000feda537 6. /build/src/IO/ReadWriteBufferFromHTTP.cpp:277: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x000000001184a4c4 7. /build/src/IO/ReadWriteBufferFromHTTP.cpp:285: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x000000001184a615 8. /build/src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x000000001184ae59 9. /build/src/IO/ReadWriteBufferFromHTTP.cpp:472: void std::__function::__policy_invoker::__call_impl[abi:se190107]>(std::__function::__policy_storage const*) @ 0x000000001184cedd 10. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001184858b 11. /build/src/IO/ReadWriteBufferFromHTTP.cpp:465: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x000000001184bf0b 12. /build/src/IO/ReadBuffer.h:60: DB::ReadBuffer::next() @ 0x000000000a148c7b 13. /build/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) @ 0x0000000011849fb2 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]>&)>&, 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&) @ 0x0000000011841980 15. /build/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) @ 0x000000001621208e 16. /build/src/Storages/StorageReplicatedMergeTree.cpp:5228: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl[abi:se190107] const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000015f9a5fe 17. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000015ed8bfd 18. /build/src/Storages/StorageReplicatedMergeTree.cpp:2514: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x0000000015ec9aab 19. /build/src/Storages/StorageReplicatedMergeTree.cpp:2349: DB::StorageReplicatedMergeTree::executeLogEntry(DB::ReplicatedMergeTreeLogEntry&) @ 0x0000000015eba91b 20. /build/src/Storages/StorageReplicatedMergeTree.cpp:3876: bool std::__function::__policy_invoker&)>::__call_impl[abi:se190107])::$_1, bool (std::shared_ptr&)>>(std::__function::__policy_storage const*, std::shared_ptr&) @ 0x0000000015f9837e 21. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000165d6fc3 22. /build/src/Storages/StorageReplicatedMergeTree.cpp:3872: DB::StorageReplicatedMergeTree::processQueueEntry(std::shared_ptr) @ 0x0000000015efc18a 23. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001624c1b2 24. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000162f9c70 25. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x00000000162fa55a 26. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc6653 27. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000000fccc4c3 28. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc3d92 29. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fcca080 30. ? @ 0x00007fbc6213eac3 31. ? @ 0x00007fbc621d0850 (version 25.3.6.10636.altinitytest (altinity build)) 2025.07.28 11:53:23.226959 [ 5112 ] {2a54930b-722b-436e-8b6f-d8e61c7adb3b} executeQuery: Code: 407. DB::Exception: Decimal math overflow: while executing 'FUNCTION divide(21_UInt8 :: 1, __table1.h : 0) -> divide(21_UInt8, __table1.h) Decimal(18, 9) : 7'. (DECIMAL_OVERFLOW) (version 25.3.6.10636.altinitytest (altinity build)) (from [::1]:48688) (comment: 00700_decimal_arithm.sql) (query 32, line 54) (in query: SELECT 21 + h, 21 - h, 84 - h, 21 * h, -21 * h, 21 / h, 84 / h FROM decimal WHERE h > 0;), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000000a074fcb 4. /build/src/Functions/FunctionBinaryArithmetic.h:789: void DB::impl_::DecimalBinaryOperation, true>::processWithRightNullmapImpl<(DB::impl_::OpCase)1, void DB::impl_::DecimalBinaryOperation, true>::process<(DB::impl_::OpCase)1, false, true, long, DB::PODArray, 4096ul, Allocator, 63ul, 64ul>>(long const&, DB::PODArray, 4096ul, Allocator, 63ul, 64ul> const&, DB::PODArray, 4096ul, Allocator, 63ul, 64ul>&, long, long, DB::PODArray, 63ul, 64ul> const*)::'lambda'(auto const&, auto const&), long, DB::PODArray, 4096ul, Allocator, 63ul, 64ul>>(long const&, long const&, DB::PODArray, 4096ul, Allocator, 63ul, 64ul>&, unsigned long, DB::PODArray, 63ul, 64ul> const*, auto) @ 0x000000000b30c22c 5. /build/src/Functions/FunctionBinaryArithmetic.h:634: void DB::impl_::DecimalBinaryOperation, true>::process<(DB::impl_::OpCase)1, false, true, long, DB::PODArray, 4096ul, Allocator, 63ul, 64ul>>(long const&, DB::PODArray, 4096ul, Allocator, 63ul, 64ul> const&, DB::PODArray, 4096ul, Allocator, 63ul, 64ul>&, long, long, DB::PODArray, 63ul, 64ul> const*) @ 0x000000000b30bf5b 6. /build/src/Functions/FunctionBinaryArithmetic.h:1485: COW::immutable_ptr DB::FunctionBinaryArithmetic::executeNumericWithDecimal, DB::DataTypeDecimal>, DB::DataTypeDecimal>, DB::DataTypeNumber, DB::DataTypeDecimal>, DB::ColumnVector, DB::ColumnDecimal>>(DB::DataTypeNumber const&, DB::DataTypeDecimal> const&, DB::ColumnConst const*, DB::ColumnConst const*, DB::ColumnVector const*, DB::ColumnDecimal> const*, unsigned long, DB::PODArray, 63ul, 64ul> const*) const @ 0x000000000b50b64e 7. /build/src/Functions/FunctionBinaryArithmetic.h:2270: COW::immutable_ptr DB::FunctionBinaryArithmetic::executeNumeric, DB::DataTypeDecimal>>(std::vector> const&, DB::DataTypeNumber const&, DB::DataTypeDecimal> const&, DB::PODArray, 63ul, 64ul> const*) const @ 0x000000000b50b244 8. /build/src/Functions/FunctionBinaryArithmetic.h:2508: auto auto bool DB::FunctionBinaryArithmetic::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&)::operator()>>(auto const&) const @ 0x000000000b505467 9. /build/src/Functions/castTypeToEither.h:18: 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&&) @ 0x000000000b504fb0 10. /build/src/Functions/FunctionBinaryArithmetic.h:846: 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&&) @ 0x000000000b503e07 11. /build/src/Functions/FunctionBinaryArithmetic.h:844: DB::FunctionBinaryArithmetic::executeImpl2(std::vector> const&, std::shared_ptr const&, unsigned long, DB::PODArray, 63ul, 64ul> const*) const @ 0x000000000b500305 12. /build/src/Functions/FunctionBinaryArithmetic.h:2410: DB::FunctionBinaryArithmetic::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000b4fe88c 13. /build/src/Functions/FunctionBinaryArithmetic.h:2645: DB::FunctionBinaryArithmeticWithConstants::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000b4fd634 14. /build/src/Functions/IFunctionAdaptors.cpp:10: DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000012d995fa 15. /build/src/Functions/IFunction.cpp:353: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d93b52 16. /build/src/Functions/IFunction.cpp:420: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d95059 17. /build/src/Functions/IFunction.cpp:498: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d95c72 18. /build/src/Interpreters/ExpressionActions.cpp:636: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x00000000145176f3 19. /build/src/Processors/Transforms/ExpressionTransform.cpp:25: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x0000000016c0b34c 20. /build/src/Processors/ISimpleTransform.h:33: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000011a9a453 21. /build/src/Processors/ISimpleTransform.cpp:89: DB::ISimpleTransform::work() @ 0x000000001699fca0 22. /build/src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x00000000169bd00f 23. /build/src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x00000000169b2105 24. /build/src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeSingleThread(unsigned long) @ 0x00000000169b23be 25. /build/src/Processors/Executors/PipelineExecutor.cpp:416: void std::__function::__policy_invoker::__call_impl[abi:se190107]>(std::__function::__policy_storage const*) @ 0x00000000169b2e3f 26. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc6653 27. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000000fccc4c3 28. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc3d92 29. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fcca080 30. ? @ 0x00007fbc6213eac3 31. ? @ 0x00007fbc621d0850 2025.07.28 11:53:23.345407 [ 5112 ] {} TCPHandler: Code: 407. DB::Exception: Decimal math overflow: while executing 'FUNCTION divide(21_UInt8 :: 1, __table1.h : 0) -> divide(21_UInt8, __table1.h) Decimal(18, 9) : 7'. (DECIMAL_OVERFLOW), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000000a074fcb 4. /build/src/Functions/FunctionBinaryArithmetic.h:789: void DB::impl_::DecimalBinaryOperation, true>::processWithRightNullmapImpl<(DB::impl_::OpCase)1, void DB::impl_::DecimalBinaryOperation, true>::process<(DB::impl_::OpCase)1, false, true, long, DB::PODArray, 4096ul, Allocator, 63ul, 64ul>>(long const&, DB::PODArray, 4096ul, Allocator, 63ul, 64ul> const&, DB::PODArray, 4096ul, Allocator, 63ul, 64ul>&, long, long, DB::PODArray, 63ul, 64ul> const*)::'lambda'(auto const&, auto const&), long, DB::PODArray, 4096ul, Allocator, 63ul, 64ul>>(long const&, long const&, DB::PODArray, 4096ul, Allocator, 63ul, 64ul>&, unsigned long, DB::PODArray, 63ul, 64ul> const*, auto) @ 0x000000000b30c22c 5. /build/src/Functions/FunctionBinaryArithmetic.h:634: void DB::impl_::DecimalBinaryOperation, true>::process<(DB::impl_::OpCase)1, false, true, long, DB::PODArray, 4096ul, Allocator, 63ul, 64ul>>(long const&, DB::PODArray, 4096ul, Allocator, 63ul, 64ul> const&, DB::PODArray, 4096ul, Allocator, 63ul, 64ul>&, long, long, DB::PODArray, 63ul, 64ul> const*) @ 0x000000000b30bf5b 6. /build/src/Functions/FunctionBinaryArithmetic.h:1485: COW::immutable_ptr DB::FunctionBinaryArithmetic::executeNumericWithDecimal, DB::DataTypeDecimal>, DB::DataTypeDecimal>, DB::DataTypeNumber, DB::DataTypeDecimal>, DB::ColumnVector, DB::ColumnDecimal>>(DB::DataTypeNumber const&, DB::DataTypeDecimal> const&, DB::ColumnConst const*, DB::ColumnConst const*, DB::ColumnVector const*, DB::ColumnDecimal> const*, unsigned long, DB::PODArray, 63ul, 64ul> const*) const @ 0x000000000b50b64e 7. /build/src/Functions/FunctionBinaryArithmetic.h:2270: COW::immutable_ptr DB::FunctionBinaryArithmetic::executeNumeric, DB::DataTypeDecimal>>(std::vector> const&, DB::DataTypeNumber const&, DB::DataTypeDecimal> const&, DB::PODArray, 63ul, 64ul> const*) const @ 0x000000000b50b244 8. /build/src/Functions/FunctionBinaryArithmetic.h:2508: auto auto bool DB::FunctionBinaryArithmetic::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&)::operator()>>(auto const&) const @ 0x000000000b505467 9. /build/src/Functions/castTypeToEither.h:18: 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&&) @ 0x000000000b504fb0 10. /build/src/Functions/FunctionBinaryArithmetic.h:846: 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&&) @ 0x000000000b503e07 11. /build/src/Functions/FunctionBinaryArithmetic.h:844: DB::FunctionBinaryArithmetic::executeImpl2(std::vector> const&, std::shared_ptr const&, unsigned long, DB::PODArray, 63ul, 64ul> const*) const @ 0x000000000b500305 12. /build/src/Functions/FunctionBinaryArithmetic.h:2410: DB::FunctionBinaryArithmetic::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000b4fe88c 13. /build/src/Functions/FunctionBinaryArithmetic.h:2645: DB::FunctionBinaryArithmeticWithConstants::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000b4fd634 14. /build/src/Functions/IFunctionAdaptors.cpp:10: DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000012d995fa 15. /build/src/Functions/IFunction.cpp:353: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d93b52 16. /build/src/Functions/IFunction.cpp:420: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d95059 17. /build/src/Functions/IFunction.cpp:498: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d95c72 18. /build/src/Interpreters/ExpressionActions.cpp:636: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x00000000145176f3 19. /build/src/Processors/Transforms/ExpressionTransform.cpp:25: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x0000000016c0b34c 20. /build/src/Processors/ISimpleTransform.h:33: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000011a9a453 21. /build/src/Processors/ISimpleTransform.cpp:89: DB::ISimpleTransform::work() @ 0x000000001699fca0 22. /build/src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x00000000169bd00f 23. /build/src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x00000000169b2105 24. /build/src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeSingleThread(unsigned long) @ 0x00000000169b23be 25. /build/src/Processors/Executors/PipelineExecutor.cpp:416: void std::__function::__policy_invoker::__call_impl[abi:se190107]>(std::__function::__policy_storage const*) @ 0x00000000169b2e3f 26. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc6653 27. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000000fccc4c3 28. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc3d92 29. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fcca080 30. ? @ 0x00007fbc6213eac3 31. ? @ 0x00007fbc621d0850 Job's origin stack trace: 0. /build/src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000000fc33b84 1. /build/src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000000fcc2ea7 2. /build/src/Common/ThreadPool.cpp:401: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fcc7f1c 3. /build/src/Common/ThreadPool.cpp:494: ThreadPoolImpl>::scheduleOrThrowOnError(std::function, Priority) @ 0x000000000fcc7a0e 4. /build/src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::spawnThreadsImpl() @ 0x00000000169b2c0c 5. /build/src/Processors/Executors/PipelineExecutor.cpp:394: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x00000000169b0ba7 6. /build/src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x00000000169b03f4 7. /build/src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:se190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169bfeab 8. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc3d92 9. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fcca080 10. ? @ 0x00007fbc6213eac3 11. ? @ 0x00007fbc621d0850 Job's origin stack trace: 0. /build/src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000000fc33b84 1. /build/src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000000fcc2ea7 2. /build/src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fcc535c 3. /build/src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000000fcc584d 4. /build/src/Common/ThreadPool.h:279: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x00000000169bf193 5. /build/src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x00000000169bf518 6. /build/src/Server/TCPHandler.cpp:1237: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x00000000168f1525 7. /build/src/Server/TCPHandler.cpp:678: DB::TCPHandler::runImpl() @ 0x00000000168e68e5 8. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 9. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 10. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 11. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 12. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 13. ? @ 0x00007fbc6213eac3 14. ? @ 0x00007fbc621d0850 2025.07.28 11:53:24.025670 [ 3965 ] {} test_13.rmt2 (7f9b740d-015c-470e-8cc6-8ba33be0dc63): auto DB::StorageReplicatedMergeTree::processQueueEntry(ReplicatedMergeTreeQueue::SelectedEntryPtr)::(anonymous class)::operator()(LogEntryPtr &) const: Code: 86. DB::HTTPException: Received error from remote server http://146b4357c08d:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Ftest%2F01165%2Ftest_13%2Frmt%2Freplicas%2F1&part=20250728_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.6.10636.altinitytest (altinity build)) '. (RECEIVED_ERROR_FROM_REMOTE_IO_SERVER), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.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 const&, int&&, String const&, unsigned long&&, String const&) @ 0x000000000feda8d9 4. /build/src/IO/HTTPCommon.cpp:104: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x000000000feda6e2 5. /build/src/IO/HTTPCommon.cpp:93: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x000000000feda537 6. /build/src/IO/ReadWriteBufferFromHTTP.cpp:277: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x000000001184a4c4 7. /build/src/IO/ReadWriteBufferFromHTTP.cpp:285: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x000000001184a615 8. /build/src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x000000001184ae59 9. /build/src/IO/ReadWriteBufferFromHTTP.cpp:472: void std::__function::__policy_invoker::__call_impl[abi:se190107]>(std::__function::__policy_storage const*) @ 0x000000001184cedd 10. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001184858b 11. /build/src/IO/ReadWriteBufferFromHTTP.cpp:465: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x000000001184bf0b 12. /build/src/IO/ReadBuffer.h:60: DB::ReadBuffer::next() @ 0x000000000a148c7b 13. /build/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) @ 0x0000000011849fb2 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]>&)>&, 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&) @ 0x0000000011841980 15. /build/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) @ 0x000000001621208e 16. /build/src/Storages/StorageReplicatedMergeTree.cpp:5228: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl[abi:se190107] const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000015f9a5fe 17. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000015ed8bfd 18. /build/src/Storages/StorageReplicatedMergeTree.cpp:2514: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x0000000015ec9aab 19. /build/src/Storages/StorageReplicatedMergeTree.cpp:2349: DB::StorageReplicatedMergeTree::executeLogEntry(DB::ReplicatedMergeTreeLogEntry&) @ 0x0000000015eba91b 20. /build/src/Storages/StorageReplicatedMergeTree.cpp:3876: bool std::__function::__policy_invoker&)>::__call_impl[abi:se190107])::$_1, bool (std::shared_ptr&)>>(std::__function::__policy_storage const*, std::shared_ptr&) @ 0x0000000015f9837e 21. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000165d6fc3 22. /build/src/Storages/StorageReplicatedMergeTree.cpp:3872: DB::StorageReplicatedMergeTree::processQueueEntry(std::shared_ptr) @ 0x0000000015efc18a 23. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001624c1b2 24. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000162f9c70 25. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x00000000162fa55a 26. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc6653 27. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000000fccc4c3 28. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc3d92 29. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fcca080 30. ? @ 0x00007fbc6213eac3 31. ? @ 0x00007fbc621d0850 (version 25.3.6.10636.altinitytest (altinity build)) 2025.07.28 11:53:24.312948 [ 3977 ] {} test_13.rmt2 (7f9b740d-015c-470e-8cc6-8ba33be0dc63): auto DB::StorageReplicatedMergeTree::processQueueEntry(ReplicatedMergeTreeQueue::SelectedEntryPtr)::(anonymous class)::operator()(LogEntryPtr &) const: Code: 86. DB::HTTPException: Received error from remote server http://146b4357c08d:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Ftest%2F01165%2Ftest_13%2Frmt%2Freplicas%2F1&part=20250728_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.6.10636.altinitytest (altinity build)) '. (RECEIVED_ERROR_FROM_REMOTE_IO_SERVER), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.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 const&, int&&, String const&, unsigned long&&, String const&) @ 0x000000000feda8d9 4. /build/src/IO/HTTPCommon.cpp:104: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x000000000feda6e2 5. /build/src/IO/HTTPCommon.cpp:93: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x000000000feda537 6. /build/src/IO/ReadWriteBufferFromHTTP.cpp:277: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x000000001184a4c4 7. /build/src/IO/ReadWriteBufferFromHTTP.cpp:285: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x000000001184a615 8. /build/src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x000000001184ae59 9. /build/src/IO/ReadWriteBufferFromHTTP.cpp:472: void std::__function::__policy_invoker::__call_impl[abi:se190107]>(std::__function::__policy_storage const*) @ 0x000000001184cedd 10. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001184858b 11. /build/src/IO/ReadWriteBufferFromHTTP.cpp:465: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x000000001184bf0b 12. /build/src/IO/ReadBuffer.h:60: DB::ReadBuffer::next() @ 0x000000000a148c7b 13. /build/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) @ 0x0000000011849fb2 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]>&)>&, 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&) @ 0x0000000011841980 15. /build/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) @ 0x000000001621208e 16. /build/src/Storages/StorageReplicatedMergeTree.cpp:5228: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl[abi:se190107] const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000015f9a5fe 17. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000015ed8bfd 18. /build/src/Storages/StorageReplicatedMergeTree.cpp:2514: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x0000000015ec9aab 19. /build/src/Storages/StorageReplicatedMergeTree.cpp:2349: DB::StorageReplicatedMergeTree::executeLogEntry(DB::ReplicatedMergeTreeLogEntry&) @ 0x0000000015eba91b 20. /build/src/Storages/StorageReplicatedMergeTree.cpp:3876: bool std::__function::__policy_invoker&)>::__call_impl[abi:se190107])::$_1, bool (std::shared_ptr&)>>(std::__function::__policy_storage const*, std::shared_ptr&) @ 0x0000000015f9837e 21. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000165d6fc3 22. /build/src/Storages/StorageReplicatedMergeTree.cpp:3872: DB::StorageReplicatedMergeTree::processQueueEntry(std::shared_ptr) @ 0x0000000015efc18a 23. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001624c1b2 24. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000162f9c70 25. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x00000000162fa55a 26. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc6653 27. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000000fccc4c3 28. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc3d92 29. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fcca080 30. ? @ 0x00007fbc6213eac3 31. ? @ 0x00007fbc621d0850 (version 25.3.6.10636.altinitytest (altinity build)) 2025.07.28 11:53:24.804283 [ 17270 ] {} TCPHandler: Code: 164. DB::Exception: Cannot modify 'join_use_nulls' setting in readonly mode. (READONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:111: DB::Exception::Exception(PreformattedMessage const&, int) @ 0x0000000011806cec 3. /build/src/Access/SettingsConstraints.cpp:319: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000013859604 4. /build/src/Access/SettingsConstraints.cpp:300: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000013858faf 5. /build/src/Access/SettingsConstraints.cpp:209: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000013859223 6. /build/src/Interpreters/Context.cpp:2690: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000014436134 7. /build/src/Interpreters/Context.cpp:2729: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x000000001443662b 8. /build/src/Server/TCPHandler.cpp:2158: DB::TCPHandler::processQuery(std::optional&) @ 0x00000000168f61df 9. /build/src/Server/TCPHandler.cpp:918: DB::TCPHandler::receivePacketsExpectQuery(std::optional&) @ 0x00000000168ef965 10. /build/src/Server/TCPHandler.cpp:491: DB::TCPHandler::runImpl() @ 0x00000000168e5eb4 11. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 12. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 13. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 14. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 15. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 16. ? @ 0x00007fbc6213eac3 17. ? @ 0x00007fbc621d0850 2025.07.28 11:53:24.848545 [ 17270 ] {} 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. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000000a074fcb 4. /build/src/Server/TCPHandler.cpp:897: DB::TCPHandler::receivePacketsExpectQuery(std::optional&) @ 0x00000000168efa89 5. /build/src/Server/TCPHandler.cpp:491: DB::TCPHandler::runImpl() @ 0x00000000168e5eb4 6. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 7. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 8. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 9. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 10. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 11. ? @ 0x00007fbc6213eac3 12. ? @ 0x00007fbc621d0850 2025.07.28 11:53:24.904223 [ 17207 ] {f6177003-b4f0-458b-b6dc-bc188ffc084a} executeQuery: Code: 676. DB::Exception: Invalid IPv6 value: In scope SELECT CAST('test', 'IPv6'). (CANNOT_PARSE_IPV6) (version 25.3.6.10636.altinitytest (altinity build)) (from [::1]:48582) (comment: 02234_cast_to_ip_address.sql) (query 51, line 74) (in query: SELECT cast('test' , 'IPv6');), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000000a074fcb 4. /build/src/Functions/FunctionsCodingIP.h:198: COW::immutable_ptr DB::detail::convertToIPv6<(DB::IPStringToNumExceptionMode)0, DB::ColumnVector, DB::ColumnString>(DB::ColumnString const&, DB::PODArray, 63ul, 64ul> const*) @ 0x0000000012df947b 5. /build/src/Functions/FunctionsCodingIP.h:220: COW::immutable_ptr DB::convertToIPv6<(DB::IPStringToNumExceptionMode)0, DB::ColumnVector>(COW::immutable_ptr, DB::PODArray, 63ul, 64ul> const*) @ 0x0000000012df7810 6. /build/src/Functions/FunctionsConversion.h:6017: bool DB::detail::FunctionCast::prepareImpl(std::shared_ptr const&, std::shared_ptr const&, bool) const::'lambda0'(auto const&)::operator()>(auto const&) 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 @ 0x0000000012df72ca 7. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: COW::immutable_ptr std::__function::__policy_invoker::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)>::__call_impl[abi:se190107] const&, std::shared_ptr const&, bool) const::'lambda0'(auto const&)::operator()>(auto 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) @ 0x0000000012df7189 8. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000012ddcb1b 9. /build/src/Functions/IFunction.h:57: DB::IExecutableFunction::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000a08134a 10. /build/src/Functions/IFunction.cpp:351: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d93b02 11. /build/src/Functions/IFunction.cpp:177: DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d93698 12. /build/src/Functions/IFunction.cpp:343: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d93aad 13. /build/src/Functions/IFunction.cpp:424: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d94e1b 14. /build/src/Functions/IFunction.cpp:498: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d95c72 15. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3567: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000014034494 16. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3838: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000014019a9e 17. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3980: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000014018e31 18. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:4304: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000014042fa7 19. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5605: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000014013749 20. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000140127f9 21. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000014011fce 22. /build/src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000001406ce8a 23. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000014973b42 24. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000001497268d 25. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000014974d24 26. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001492924b 27. /build/src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88641 28. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 29. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 30. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 31. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 2025.07.28 11:53:24.917706 [ 17207 ] {} TCPHandler: Code: 676. DB::Exception: Invalid IPv6 value: In scope SELECT CAST('test', 'IPv6'). (CANNOT_PARSE_IPV6), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000000a074fcb 4. /build/src/Functions/FunctionsCodingIP.h:198: COW::immutable_ptr DB::detail::convertToIPv6<(DB::IPStringToNumExceptionMode)0, DB::ColumnVector, DB::ColumnString>(DB::ColumnString const&, DB::PODArray, 63ul, 64ul> const*) @ 0x0000000012df947b 5. /build/src/Functions/FunctionsCodingIP.h:220: COW::immutable_ptr DB::convertToIPv6<(DB::IPStringToNumExceptionMode)0, DB::ColumnVector>(COW::immutable_ptr, DB::PODArray, 63ul, 64ul> const*) @ 0x0000000012df7810 6. /build/src/Functions/FunctionsConversion.h:6017: bool DB::detail::FunctionCast::prepareImpl(std::shared_ptr const&, std::shared_ptr const&, bool) const::'lambda0'(auto const&)::operator()>(auto const&) 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 @ 0x0000000012df72ca 7. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: COW::immutable_ptr std::__function::__policy_invoker::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)>::__call_impl[abi:se190107] const&, std::shared_ptr const&, bool) const::'lambda0'(auto const&)::operator()>(auto 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) @ 0x0000000012df7189 8. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000012ddcb1b 9. /build/src/Functions/IFunction.h:57: DB::IExecutableFunction::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000a08134a 10. /build/src/Functions/IFunction.cpp:351: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d93b02 11. /build/src/Functions/IFunction.cpp:177: DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d93698 12. /build/src/Functions/IFunction.cpp:343: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d93aad 13. /build/src/Functions/IFunction.cpp:424: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d94e1b 14. /build/src/Functions/IFunction.cpp:498: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d95c72 15. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3567: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000014034494 16. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3838: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000014019a9e 17. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3980: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000014018e31 18. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:4304: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000014042fa7 19. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5605: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000014013749 20. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000140127f9 21. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000014011fce 22. /build/src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000001406ce8a 23. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000014973b42 24. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000001497268d 25. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000014974d24 26. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001492924b 27. /build/src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88641 28. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 29. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 30. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 31. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 2025.07.28 11:53:25.002224 [ 17252 ] {1739c7ed-0458-465b-946f-d55aa0e7d14b} StorageDistributed (tt6): Name of remote database is empty. Default database will be used implicitly. 2025.07.28 11:53:25.090100 [ 17270 ] {} TCPHandler: Code: 164. DB::Exception: Cannot modify 'join_use_nulls' setting in readonly mode. (READONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:111: DB::Exception::Exception(PreformattedMessage const&, int) @ 0x0000000011806cec 3. /build/src/Access/SettingsConstraints.cpp:319: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000013859604 4. /build/src/Access/SettingsConstraints.cpp:300: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000013858faf 5. /build/src/Access/SettingsConstraints.cpp:209: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000013859223 6. /build/src/Interpreters/Context.cpp:2690: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000014436134 7. /build/src/Interpreters/Context.cpp:2729: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x000000001443662b 8. /build/src/Server/TCPHandler.cpp:2158: DB::TCPHandler::processQuery(std::optional&) @ 0x00000000168f61df 9. /build/src/Server/TCPHandler.cpp:918: DB::TCPHandler::receivePacketsExpectQuery(std::optional&) @ 0x00000000168ef965 10. /build/src/Server/TCPHandler.cpp:491: DB::TCPHandler::runImpl() @ 0x00000000168e5eb4 11. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 12. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 13. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 14. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 15. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 16. ? @ 0x00007fbc6213eac3 17. ? @ 0x00007fbc621d0850 2025.07.28 11:53:25.091997 [ 17270 ] {} 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. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000000a074fcb 4. /build/src/Server/TCPHandler.cpp:897: DB::TCPHandler::receivePacketsExpectQuery(std::optional&) @ 0x00000000168efa89 5. /build/src/Server/TCPHandler.cpp:491: DB::TCPHandler::runImpl() @ 0x00000000168e5eb4 6. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 7. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 8. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 9. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 10. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 11. ? @ 0x00007fbc6213eac3 12. ? @ 0x00007fbc621d0850 2025.07.28 11:53:25.096410 [ 5292 ] {} ExternalDictionariesLoader: Could not load external dictionary 'cc8b1a52-da70-449c-9c23-8d623c5fcc44', next update is scheduled at 2025-07-28 11:53:30: Code: 396. DB::Exception: Limit for result exceeded, max bytes: 1.00 B, current bytes: 36.00 B. (TOO_MANY_ROWS_OR_BYTES), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, char const*&, ReadableSize&&, ReadableSize&&) @ 0x0000000013bd4eeb 4. /build/src/QueryPipeline/SizeLimits.cpp:43: DB::SizeLimits::check(unsigned long, unsigned long, char const*, int, int) const @ 0x0000000013bd48a1 5. /build/src/Processors/Transforms/LimitsCheckingTransform.cpp:45: DB::LimitsCheckingTransform::transform(DB::Chunk&) @ 0x0000000016c1d2fb 6. /build/src/Processors/ISimpleTransform.h:33: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000011a9a453 7. /build/src/Processors/ISimpleTransform.cpp:89: DB::ISimpleTransform::work() @ 0x000000001699fca0 8. /build/src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x00000000169bd00f 9. /build/src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x00000000169b2105 10. /build/src/Processors/Executors/PipelineExecutor.cpp:170: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x00000000169b16a7 11. /build/src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x00000000169c081c 12. /build/src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x00000000169c0978 13. /build/src/Dictionaries/FlatDictionary.cpp:502: DB::FlatDictionary::loadData() @ 0x0000000011b424cb 14. /build/src/Dictionaries/FlatDictionary.cpp:46: DB::FlatDictionary::FlatDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, DB::FlatDictionary::Configuration, std::shared_ptr) @ 0x0000000011b42111 15. /build/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:se190107]> (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) @ 0x0000000011b5d3e2 16. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000012d8a61d 17. /build/src/Interpreters/ExternalDictionariesLoader.cpp:47: DB::ExternalDictionariesLoader::createObject(String const&, Poco::Util::AbstractConfiguration const&, String const&, String const&) const @ 0x00000000148a6f44 18. /build/src/Interpreters/ExternalLoader.cpp:1522: DB::ExternalLoader::LoadingDispatcher::loadSingleObject(String const&, DB::ExternalLoader::ObjectConfig const&, std::shared_ptr) @ 0x00000000148b2ee8 19. /build/src/Interpreters/ExternalLoader.cpp:998: DB::ExternalLoader::LoadingDispatcher::doLoading(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr) @ 0x00000000148b197d 20. /build/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()() @ 0x00000000148b5991 21. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc3d92 22. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fcca080 23. ? @ 0x00007fbc6213eac3 24. ? @ 0x00007fbc621d0850 (version 25.3.6.10636.altinitytest (altinity build)) 2025.07.28 11:53:25.406152 [ 17252 ] {0d6e8810-65e5-45c7-83d9-893c0cdf1464} executeQuery: Code: 269. DB::Exception: Cannot add dependencies for 'test_13.tt7', because it will lead to cyclic dependencies: test_13.tt6 -> [test_13.tt7]; test_13.tt7 -> [test_13.tt6]. (INFINITE_LOOP) (version 25.3.6.10636.altinitytest (altinity build)) (from [::1]:51178) (comment: 01763_max_distributed_depth.sql) (query 5, line 20) (in query: CREATE TABLE tt7 as tt6 ENGINE = Distributed('test_shard_localhost', '', 'tt6', rand());), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&) @ 0x000000000b2e312b 4. /build/src/Interpreters/DatabaseCatalog.cpp:1597: DB::DatabaseCatalog::checkTableCanBeAddedWithNoCyclicDependencies(DB::QualifiedTableName const&, std::unordered_set, std::equal_to, std::allocator> const&, std::unordered_set, std::equal_to, std::allocator> const&)::$_0::operator()(DB::TablesDependencyGraph&, std::unordered_set, std::equal_to, std::allocator> const&) const @ 0x00000000145006d8 5. /build/src/Interpreters/DatabaseCatalog.cpp:1607: DB::DatabaseCatalog::checkTableCanBeAddedWithNoCyclicDependencies(DB::QualifiedTableName const&, std::unordered_set, std::equal_to, std::allocator> const&, std::unordered_set, std::equal_to, std::allocator> const&) @ 0x0000000014500488 6. /build/src/Interpreters/InterpreterCreateQuery.cpp:1493: DB::(anonymous namespace)::checkTableCanBeAddedWithNoCyclicDependencies(DB::ASTCreateQuery const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000014903e15 7. /build/src/Interpreters/InterpreterCreateQuery.cpp:1917: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x0000000014900318 8. /build/src/Interpreters/InterpreterCreateQuery.cpp:1743: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000148f9aa9 9. /build/src/Interpreters/InterpreterCreateQuery.cpp:2352: DB::InterpreterCreateQuery::execute() @ 0x0000000014905a41 10. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88dc9 11. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 12. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 13. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 14. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 15. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 16. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 17. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 18. ? @ 0x00007fbc6213eac3 19. ? @ 0x00007fbc621d0850 2025.07.28 11:53:25.423112 [ 3970 ] {} test_13.rmt2 (7f9b740d-015c-470e-8cc6-8ba33be0dc63): auto DB::StorageReplicatedMergeTree::processQueueEntry(ReplicatedMergeTreeQueue::SelectedEntryPtr)::(anonymous class)::operator()(LogEntryPtr &) const: Code: 86. DB::HTTPException: Received error from remote server http://146b4357c08d:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Ftest%2F01165%2Ftest_13%2Frmt%2Freplicas%2F1&part=20250728_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.6.10636.altinitytest (altinity build)) '. (RECEIVED_ERROR_FROM_REMOTE_IO_SERVER), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.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 const&, int&&, String const&, unsigned long&&, String const&) @ 0x000000000feda8d9 4. /build/src/IO/HTTPCommon.cpp:104: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x000000000feda6e2 5. /build/src/IO/HTTPCommon.cpp:93: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x000000000feda537 6. /build/src/IO/ReadWriteBufferFromHTTP.cpp:277: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x000000001184a4c4 7. /build/src/IO/ReadWriteBufferFromHTTP.cpp:285: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x000000001184a615 8. /build/src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x000000001184ae59 9. /build/src/IO/ReadWriteBufferFromHTTP.cpp:472: void std::__function::__policy_invoker::__call_impl[abi:se190107]>(std::__function::__policy_storage const*) @ 0x000000001184cedd 10. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001184858b 11. /build/src/IO/ReadWriteBufferFromHTTP.cpp:465: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x000000001184bf0b 12. /build/src/IO/ReadBuffer.h:60: DB::ReadBuffer::next() @ 0x000000000a148c7b 13. /build/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) @ 0x0000000011849fb2 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]>&)>&, 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&) @ 0x0000000011841980 15. /build/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) @ 0x000000001621208e 16. /build/src/Storages/StorageReplicatedMergeTree.cpp:5228: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl[abi:se190107] const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000015f9a5fe 17. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000015ed8bfd 18. /build/src/Storages/StorageReplicatedMergeTree.cpp:2514: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x0000000015ec9aab 19. /build/src/Storages/StorageReplicatedMergeTree.cpp:2349: DB::StorageReplicatedMergeTree::executeLogEntry(DB::ReplicatedMergeTreeLogEntry&) @ 0x0000000015eba91b 20. /build/src/Storages/StorageReplicatedMergeTree.cpp:3876: bool std::__function::__policy_invoker&)>::__call_impl[abi:se190107])::$_1, bool (std::shared_ptr&)>>(std::__function::__policy_storage const*, std::shared_ptr&) @ 0x0000000015f9837e 21. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000165d6fc3 22. /build/src/Storages/StorageReplicatedMergeTree.cpp:3872: DB::StorageReplicatedMergeTree::processQueueEntry(std::shared_ptr) @ 0x0000000015efc18a 23. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001624c1b2 24. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000162f9c70 25. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x00000000162fa55a 26. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc6653 27. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000000fccc4c3 28. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc3d92 29. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fcca080 30. ? @ 0x00007fbc6213eac3 31. ? @ 0x00007fbc621d0850 (version 25.3.6.10636.altinitytest (altinity build)) 2025.07.28 11:53:25.426177 [ 17252 ] {} TCPHandler: Code: 269. DB::Exception: Cannot add dependencies for 'test_13.tt7', because it will lead to cyclic dependencies: test_13.tt6 -> [test_13.tt7]; test_13.tt7 -> [test_13.tt6]. (INFINITE_LOOP), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&) @ 0x000000000b2e312b 4. /build/src/Interpreters/DatabaseCatalog.cpp:1597: DB::DatabaseCatalog::checkTableCanBeAddedWithNoCyclicDependencies(DB::QualifiedTableName const&, std::unordered_set, std::equal_to, std::allocator> const&, std::unordered_set, std::equal_to, std::allocator> const&)::$_0::operator()(DB::TablesDependencyGraph&, std::unordered_set, std::equal_to, std::allocator> const&) const @ 0x00000000145006d8 5. /build/src/Interpreters/DatabaseCatalog.cpp:1607: DB::DatabaseCatalog::checkTableCanBeAddedWithNoCyclicDependencies(DB::QualifiedTableName const&, std::unordered_set, std::equal_to, std::allocator> const&, std::unordered_set, std::equal_to, std::allocator> const&) @ 0x0000000014500488 6. /build/src/Interpreters/InterpreterCreateQuery.cpp:1493: DB::(anonymous namespace)::checkTableCanBeAddedWithNoCyclicDependencies(DB::ASTCreateQuery const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000014903e15 7. /build/src/Interpreters/InterpreterCreateQuery.cpp:1917: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x0000000014900318 8. /build/src/Interpreters/InterpreterCreateQuery.cpp:1743: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000148f9aa9 9. /build/src/Interpreters/InterpreterCreateQuery.cpp:2352: DB::InterpreterCreateQuery::execute() @ 0x0000000014905a41 10. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88dc9 11. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 12. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 13. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 14. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 15. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 16. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 17. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 18. ? @ 0x00007fbc6213eac3 19. ? @ 0x00007fbc621d0850 2025.07.28 11:53:25.445544 [ 4963 ] {536c8c31-8ca2-4307-bc5b-349fb32d5e3b} executeQuery: Code: 219. DB::Exception: New table appeared in database being dropped or detached. Try again. (DATABASE_NOT_EMPTY) (version 25.3.6.10636.altinitytest (altinity build)) (from [::1]:52906) (comment: 00374_json_each_row_input_with_noisy_fields.sh) (in query: DROP DATABASE IF EXISTS test_tkiu7992 SYNC ), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000000a074fcb 4. /build/src/Interpreters/DatabaseCatalog.cpp:608: DB::DatabaseCatalog::detachDatabase(std::shared_ptr, String const&, bool, bool) @ 0x00000000144f41b9 5. /build/src/Interpreters/InterpreterDropQuery.cpp:482: DB::InterpreterDropQuery::executeToDatabaseImpl(DB::ASTDropQuery const&, std::shared_ptr&, std::vector, DB::UUIDTag>, std::allocator, DB::UUIDTag>>>&) @ 0x00000000149179be 6. /build/src/Interpreters/InterpreterDropQuery.cpp:363: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x0000000014913988 7. /build/src/Interpreters/InterpreterDropQuery.cpp:99: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000014913142 8. /build/src/Interpreters/InterpreterDropQuery.cpp:72: DB::InterpreterDropQuery::execute() @ 0x0000000014912b65 9. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88dc9 10. /build/src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x0000000014c8ca7b 11. /build/src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000001686da12 12. /build/src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x0000000016870807 13. /build/src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x0000000016907e99 14. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 15. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 16. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 17. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 18. ? @ 0x00007fbc6213eac3 19. ? @ 0x00007fbc621d0850 2025.07.28 11:53:25.448481 [ 4963 ] {536c8c31-8ca2-4307-bc5b-349fb32d5e3b} 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. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000000a074fcb 4. /build/src/Interpreters/DatabaseCatalog.cpp:608: DB::DatabaseCatalog::detachDatabase(std::shared_ptr, String const&, bool, bool) @ 0x00000000144f41b9 5. /build/src/Interpreters/InterpreterDropQuery.cpp:482: DB::InterpreterDropQuery::executeToDatabaseImpl(DB::ASTDropQuery const&, std::shared_ptr&, std::vector, DB::UUIDTag>, std::allocator, DB::UUIDTag>>>&) @ 0x00000000149179be 6. /build/src/Interpreters/InterpreterDropQuery.cpp:363: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x0000000014913988 7. /build/src/Interpreters/InterpreterDropQuery.cpp:99: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000014913142 8. /build/src/Interpreters/InterpreterDropQuery.cpp:72: DB::InterpreterDropQuery::execute() @ 0x0000000014912b65 9. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88dc9 10. /build/src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x0000000014c8ca7b 11. /build/src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000001686da12 12. /build/src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x0000000016870807 13. /build/src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x0000000016907e99 14. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 15. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 16. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 17. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 18. ? @ 0x00007fbc6213eac3 19. ? @ 0x00007fbc621d0850 (version 25.3.6.10636.altinitytest (altinity build)) 2025.07.28 11:53:25.566646 [ 17191 ] {ec4131ef-df66-4bca-876a-26a93360b599} executeQuery: Code: 219. DB::Exception: New table appeared in database being dropped or detached. Try again. (DATABASE_NOT_EMPTY) (version 25.3.6.10636.altinitytest (altinity build)) (from [::1]:57210) (comment: 01142_join_lc_and_nullable_in_key.sql) (in query: DROP DATABASE IF EXISTS test_4ku7ozlq SYNC ), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000000a074fcb 4. /build/src/Interpreters/DatabaseCatalog.cpp:608: DB::DatabaseCatalog::detachDatabase(std::shared_ptr, String const&, bool, bool) @ 0x00000000144f41b9 5. /build/src/Interpreters/InterpreterDropQuery.cpp:482: DB::InterpreterDropQuery::executeToDatabaseImpl(DB::ASTDropQuery const&, std::shared_ptr&, std::vector, DB::UUIDTag>, std::allocator, DB::UUIDTag>>>&) @ 0x00000000149179be 6. /build/src/Interpreters/InterpreterDropQuery.cpp:363: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x0000000014913988 7. /build/src/Interpreters/InterpreterDropQuery.cpp:99: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000014913142 8. /build/src/Interpreters/InterpreterDropQuery.cpp:72: DB::InterpreterDropQuery::execute() @ 0x0000000014912b65 9. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88dc9 10. /build/src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x0000000014c8ca7b 11. /build/src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000001686da12 12. /build/src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x0000000016870807 13. /build/src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x0000000016907e99 14. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 15. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 16. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 17. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 18. ? @ 0x00007fbc6213eac3 19. ? @ 0x00007fbc621d0850 2025.07.28 11:53:25.568700 [ 17191 ] {ec4131ef-df66-4bca-876a-26a93360b599} 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. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000000a074fcb 4. /build/src/Interpreters/DatabaseCatalog.cpp:608: DB::DatabaseCatalog::detachDatabase(std::shared_ptr, String const&, bool, bool) @ 0x00000000144f41b9 5. /build/src/Interpreters/InterpreterDropQuery.cpp:482: DB::InterpreterDropQuery::executeToDatabaseImpl(DB::ASTDropQuery const&, std::shared_ptr&, std::vector, DB::UUIDTag>, std::allocator, DB::UUIDTag>>>&) @ 0x00000000149179be 6. /build/src/Interpreters/InterpreterDropQuery.cpp:363: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x0000000014913988 7. /build/src/Interpreters/InterpreterDropQuery.cpp:99: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000014913142 8. /build/src/Interpreters/InterpreterDropQuery.cpp:72: DB::InterpreterDropQuery::execute() @ 0x0000000014912b65 9. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88dc9 10. /build/src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x0000000014c8ca7b 11. /build/src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000001686da12 12. /build/src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x0000000016870807 13. /build/src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x0000000016907e99 14. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 15. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 16. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 17. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 18. ? @ 0x00007fbc6213eac3 19. ? @ 0x00007fbc621d0850 (version 25.3.6.10636.altinitytest (altinity build)) 2025.07.28 11:53:25.911105 [ 4963 ] {} DynamicQueryHandler: Code: 164. DB::Exception: Cannot modify 'readonly' setting in readonly mode: , while trying to set settings profile readonly: in attempt to set the value of setting 'profile' to 'readonly'. (READONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:111: DB::Exception::Exception(PreformattedMessage const&, int) @ 0x0000000011806cec 3. /build/src/Access/SettingsConstraints.cpp:319: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000013859604 4. /build/src/Access/SettingsConstraints.cpp:300: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000013858faf 5. /build/src/Access/SettingsConstraints.cpp:194: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges const&, DB::SettingSource) const @ 0x00000000138591b3 6. /build/src/Interpreters/Context.cpp:2683: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges const&, DB::SettingSource) @ 0x000000001442e1b4 7. /build/src/Interpreters/Context.cpp:1850: DB::Context::setCurrentProfilesWithLock(DB::SettingsProfilesInfo const&, bool, std::lock_guard const&) @ 0x000000001442bd0a 8. /build/src/Interpreters/Context.cpp:1844: DB::Context::setCurrentProfileWithLock(String const&, bool, std::lock_guard const&) @ 0x000000001442dfde 9. /build/src/Interpreters/Context.cpp:2595: DB::Context::applySettingChangeWithLock(DB::SettingChange const&, std::lock_guard const&) @ 0x0000000014435778 10. /build/src/Interpreters/Context.cpp:2622: DB::Context::applySettingsChanges(DB::SettingsChanges const&) @ 0x0000000014435d8e 11. /build/src/Server/HTTPHandler.cpp:458: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000001686d17a 12. /build/src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x0000000016870807 13. /build/src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x0000000016907e99 14. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 15. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 16. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 17. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 18. ? @ 0x00007fbc6213eac3 19. ? @ 0x00007fbc621d0850 (version 25.3.6.10636.altinitytest (altinity build)) 2025.07.28 11:53:26.025370 [ 5112 ] {fac8b615-b08f-4e1d-a480-e54e7812d1f1} executeQuery: Code: 153. DB::Exception: Division by zero: In scope SELECT 1 / toDecimal32(0, 0). (ILLEGAL_DIVISION) (version 25.3.6.10636.altinitytest (altinity build)) (from [::1]:48688) (comment: 00700_decimal_arithm.sql) (query 43, line 70) (in query: SELECT 1 / toDecimal32(0, 0);), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000000a074fcb 4. /build/src/Functions/DivisionUtils.h:26: void DB::throwIfDivisionLeadsToFPE(int, int) @ 0x000000000b309e93 5. /build/src/Functions/FunctionBinaryArithmetic.h:0: DB::Decimal DB::FunctionBinaryArithmetic::helperInvokeEither, false>, DB::impl_::DecimalBinaryOperation, true>, DB::Decimal, int, int, DB::Decimal, DB::Decimal>(int, int, DB::Decimal, DB::Decimal) const requires !is_decimal && !is_decimal @ 0x000000000b50b01f 6. /build/src/Functions/FunctionBinaryArithmetic.h:1560: COW::immutable_ptr DB::FunctionBinaryArithmetic::executeNumericWithDecimal, DB::DataTypeDecimal>, DB::DataTypeDecimal>, DB::DataTypeNumber, DB::DataTypeDecimal>, DB::ColumnVector, DB::ColumnDecimal>>(DB::DataTypeNumber const&, DB::DataTypeDecimal> const&, DB::ColumnConst const*, DB::ColumnConst const*, DB::ColumnVector const*, DB::ColumnDecimal> const*, unsigned long, DB::PODArray, 63ul, 64ul> const*) const @ 0x000000000b50aaf1 7. /build/src/Functions/FunctionBinaryArithmetic.h:2270: COW::immutable_ptr DB::FunctionBinaryArithmetic::executeNumeric, DB::DataTypeDecimal>>(std::vector> const&, DB::DataTypeNumber const&, DB::DataTypeDecimal> const&, DB::PODArray, 63ul, 64ul> const*) const @ 0x000000000b50a8e4 8. /build/src/Functions/FunctionBinaryArithmetic.h:2508: auto auto bool DB::FunctionBinaryArithmetic::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&)::operator()>>(auto const&) const @ 0x000000000b5053e7 9. /build/src/Functions/castTypeToEither.h:18: 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&&) @ 0x000000000b504f67 10. /build/src/Functions/FunctionBinaryArithmetic.h:846: 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&&) @ 0x000000000b503e07 11. /build/src/Functions/FunctionBinaryArithmetic.h:844: DB::FunctionBinaryArithmetic::executeImpl2(std::vector> const&, std::shared_ptr const&, unsigned long, DB::PODArray, 63ul, 64ul> const*) const @ 0x000000000b500305 12. /build/src/Functions/FunctionBinaryArithmetic.h:2410: DB::FunctionBinaryArithmetic::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000b4fe88c 13. /build/src/Functions/FunctionBinaryArithmetic.h:2645: DB::FunctionBinaryArithmeticWithConstants::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000b4fd634 14. /build/src/Functions/IFunction.h:437: DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000a069f2a 15. /build/src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000012d9965a 16. /build/src/Functions/IFunction.cpp:351: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d93b02 17. /build/src/Functions/IFunction.cpp:420: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d95059 18. /build/src/Functions/IFunction.cpp:498: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d95c72 19. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3567: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000014034494 20. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3838: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000014019a9e 21. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3980: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000014018e31 22. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:4304: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000014042fa7 23. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5605: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000014013749 24. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000140127f9 25. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000014011fce 26. /build/src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000001406ce8a 27. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000014973b42 28. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000001497268d 29. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000014974d24 30. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001492924b 31. /build/src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88641 2025.07.28 11:53:26.029829 [ 5112 ] {} TCPHandler: Code: 153. DB::Exception: Division by zero: In scope SELECT 1 / toDecimal32(0, 0). (ILLEGAL_DIVISION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000000a074fcb 4. /build/src/Functions/DivisionUtils.h:26: void DB::throwIfDivisionLeadsToFPE(int, int) @ 0x000000000b309e93 5. /build/src/Functions/FunctionBinaryArithmetic.h:0: DB::Decimal DB::FunctionBinaryArithmetic::helperInvokeEither, false>, DB::impl_::DecimalBinaryOperation, true>, DB::Decimal, int, int, DB::Decimal, DB::Decimal>(int, int, DB::Decimal, DB::Decimal) const requires !is_decimal && !is_decimal @ 0x000000000b50b01f 6. /build/src/Functions/FunctionBinaryArithmetic.h:1560: COW::immutable_ptr DB::FunctionBinaryArithmetic::executeNumericWithDecimal, DB::DataTypeDecimal>, DB::DataTypeDecimal>, DB::DataTypeNumber, DB::DataTypeDecimal>, DB::ColumnVector, DB::ColumnDecimal>>(DB::DataTypeNumber const&, DB::DataTypeDecimal> const&, DB::ColumnConst const*, DB::ColumnConst const*, DB::ColumnVector const*, DB::ColumnDecimal> const*, unsigned long, DB::PODArray, 63ul, 64ul> const*) const @ 0x000000000b50aaf1 7. /build/src/Functions/FunctionBinaryArithmetic.h:2270: COW::immutable_ptr DB::FunctionBinaryArithmetic::executeNumeric, DB::DataTypeDecimal>>(std::vector> const&, DB::DataTypeNumber const&, DB::DataTypeDecimal> const&, DB::PODArray, 63ul, 64ul> const*) const @ 0x000000000b50a8e4 8. /build/src/Functions/FunctionBinaryArithmetic.h:2508: auto auto bool DB::FunctionBinaryArithmetic::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&)::operator()>>(auto const&) const @ 0x000000000b5053e7 9. /build/src/Functions/castTypeToEither.h:18: 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&&) @ 0x000000000b504f67 10. /build/src/Functions/FunctionBinaryArithmetic.h:846: 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&&) @ 0x000000000b503e07 11. /build/src/Functions/FunctionBinaryArithmetic.h:844: DB::FunctionBinaryArithmetic::executeImpl2(std::vector> const&, std::shared_ptr const&, unsigned long, DB::PODArray, 63ul, 64ul> const*) const @ 0x000000000b500305 12. /build/src/Functions/FunctionBinaryArithmetic.h:2410: DB::FunctionBinaryArithmetic::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000b4fe88c 13. /build/src/Functions/FunctionBinaryArithmetic.h:2645: DB::FunctionBinaryArithmeticWithConstants::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000b4fd634 14. /build/src/Functions/IFunction.h:437: DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000a069f2a 15. /build/src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000012d9965a 16. /build/src/Functions/IFunction.cpp:351: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d93b02 17. /build/src/Functions/IFunction.cpp:420: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d95059 18. /build/src/Functions/IFunction.cpp:498: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d95c72 19. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3567: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000014034494 20. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3838: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000014019a9e 21. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3980: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000014018e31 22. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:4304: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000014042fa7 23. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5605: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000014013749 24. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000140127f9 25. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000014011fce 26. /build/src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000001406ce8a 27. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000014973b42 28. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000001497268d 29. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000014974d24 30. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001492924b 31. /build/src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88641 2025.07.28 11:53:26.034835 [ 3965 ] {} test_13.rmt2 (7f9b740d-015c-470e-8cc6-8ba33be0dc63): auto DB::StorageReplicatedMergeTree::processQueueEntry(ReplicatedMergeTreeQueue::SelectedEntryPtr)::(anonymous class)::operator()(LogEntryPtr &) const: Code: 86. DB::HTTPException: Received error from remote server http://146b4357c08d:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Ftest%2F01165%2Ftest_13%2Frmt%2Freplicas%2F1&part=20250728_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.6.10636.altinitytest (altinity build)) '. (RECEIVED_ERROR_FROM_REMOTE_IO_SERVER), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.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 const&, int&&, String const&, unsigned long&&, String const&) @ 0x000000000feda8d9 4. /build/src/IO/HTTPCommon.cpp:104: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x000000000feda6e2 5. /build/src/IO/HTTPCommon.cpp:93: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x000000000feda537 6. /build/src/IO/ReadWriteBufferFromHTTP.cpp:277: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x000000001184a4c4 7. /build/src/IO/ReadWriteBufferFromHTTP.cpp:285: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x000000001184a615 8. /build/src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x000000001184ae59 9. /build/src/IO/ReadWriteBufferFromHTTP.cpp:472: void std::__function::__policy_invoker::__call_impl[abi:se190107]>(std::__function::__policy_storage const*) @ 0x000000001184cedd 10. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001184858b 11. /build/src/IO/ReadWriteBufferFromHTTP.cpp:465: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x000000001184bf0b 12. /build/src/IO/ReadBuffer.h:60: DB::ReadBuffer::next() @ 0x000000000a148c7b 13. /build/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) @ 0x0000000011849fb2 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]>&)>&, 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&) @ 0x0000000011841980 15. /build/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) @ 0x000000001621208e 16. /build/src/Storages/StorageReplicatedMergeTree.cpp:5228: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl[abi:se190107] const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000015f9a5fe 17. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000015ed8bfd 18. /build/src/Storages/StorageReplicatedMergeTree.cpp:2514: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x0000000015ec9aab 19. /build/src/Storages/StorageReplicatedMergeTree.cpp:2349: DB::StorageReplicatedMergeTree::executeLogEntry(DB::ReplicatedMergeTreeLogEntry&) @ 0x0000000015eba91b 20. /build/src/Storages/StorageReplicatedMergeTree.cpp:3876: bool std::__function::__policy_invoker&)>::__call_impl[abi:se190107])::$_1, bool (std::shared_ptr&)>>(std::__function::__policy_storage const*, std::shared_ptr&) @ 0x0000000015f9837e 21. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000165d6fc3 22. /build/src/Storages/StorageReplicatedMergeTree.cpp:3872: DB::StorageReplicatedMergeTree::processQueueEntry(std::shared_ptr) @ 0x0000000015efc18a 23. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001624c1b2 24. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000162f9c70 25. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x00000000162fa55a 26. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc6653 27. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000000fccc4c3 28. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc3d92 29. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fcca080 30. ? @ 0x00007fbc6213eac3 31. ? @ 0x00007fbc621d0850 (version 25.3.6.10636.altinitytest (altinity build)) 2025.07.28 11:53:26.365251 [ 5112 ] {de90e41d-1e7d-4fc0-995e-6d10aafdb40f} executeQuery: Code: 153. DB::Exception: Division by zero: In scope SELECT 1 / toDecimal64(0, 1). (ILLEGAL_DIVISION) (version 25.3.6.10636.altinitytest (altinity build)) (from [::1]:48688) (comment: 00700_decimal_arithm.sql) (query 44, line 71) (in query: SELECT 1 / toDecimal64(0, 1);), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000000a074fcb 4. /build/src/Functions/DivisionUtils.h:26: void DB::throwIfDivisionLeadsToFPE(long, long) @ 0x000000000b2fd11e 5. /build/src/Functions/FunctionBinaryArithmetic.h:0: DB::Decimal DB::FunctionBinaryArithmetic::helperInvokeEither, false>, DB::impl_::DecimalBinaryOperation, true>, DB::Decimal, long, long, DB::Decimal, DB::Decimal>(long, long, DB::Decimal, DB::Decimal) const requires !is_decimal && !is_decimal @ 0x000000000b50b9ac 6. /build/src/Functions/FunctionBinaryArithmetic.h:1560: COW::immutable_ptr DB::FunctionBinaryArithmetic::executeNumericWithDecimal, DB::DataTypeDecimal>, DB::DataTypeDecimal>, DB::DataTypeNumber, DB::DataTypeDecimal>, DB::ColumnVector, DB::ColumnDecimal>>(DB::DataTypeNumber const&, DB::DataTypeDecimal> const&, DB::ColumnConst const*, DB::ColumnConst const*, DB::ColumnVector const*, DB::ColumnDecimal> const*, unsigned long, DB::PODArray, 63ul, 64ul> const*) const @ 0x000000000b50b54d 7. /build/src/Functions/FunctionBinaryArithmetic.h:2270: COW::immutable_ptr DB::FunctionBinaryArithmetic::executeNumeric, DB::DataTypeDecimal>>(std::vector> const&, DB::DataTypeNumber const&, DB::DataTypeDecimal> const&, DB::PODArray, 63ul, 64ul> const*) const @ 0x000000000b50b244 8. /build/src/Functions/FunctionBinaryArithmetic.h:2508: auto auto bool DB::FunctionBinaryArithmetic::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&)::operator()>>(auto const&) const @ 0x000000000b505467 9. /build/src/Functions/castTypeToEither.h:18: 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&&) @ 0x000000000b504fb0 10. /build/src/Functions/FunctionBinaryArithmetic.h:846: 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&&) @ 0x000000000b503e07 11. /build/src/Functions/FunctionBinaryArithmetic.h:844: DB::FunctionBinaryArithmetic::executeImpl2(std::vector> const&, std::shared_ptr const&, unsigned long, DB::PODArray, 63ul, 64ul> const*) const @ 0x000000000b500305 12. /build/src/Functions/FunctionBinaryArithmetic.h:2410: DB::FunctionBinaryArithmetic::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000b4fe88c 13. /build/src/Functions/FunctionBinaryArithmetic.h:2645: DB::FunctionBinaryArithmeticWithConstants::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000b4fd634 14. /build/src/Functions/IFunction.h:437: DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000a069f2a 15. /build/src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000012d9965a 16. /build/src/Functions/IFunction.cpp:351: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d93b02 17. /build/src/Functions/IFunction.cpp:420: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d95059 18. /build/src/Functions/IFunction.cpp:498: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d95c72 19. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3567: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000014034494 20. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3838: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000014019a9e 21. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3980: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000014018e31 22. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:4304: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000014042fa7 23. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5605: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000014013749 24. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000140127f9 25. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000014011fce 26. /build/src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000001406ce8a 27. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000014973b42 28. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000001497268d 29. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000014974d24 30. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001492924b 31. /build/src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88641 2025.07.28 11:53:26.372769 [ 5112 ] {} TCPHandler: Code: 153. DB::Exception: Division by zero: In scope SELECT 1 / toDecimal64(0, 1). (ILLEGAL_DIVISION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000000a074fcb 4. /build/src/Functions/DivisionUtils.h:26: void DB::throwIfDivisionLeadsToFPE(long, long) @ 0x000000000b2fd11e 5. /build/src/Functions/FunctionBinaryArithmetic.h:0: DB::Decimal DB::FunctionBinaryArithmetic::helperInvokeEither, false>, DB::impl_::DecimalBinaryOperation, true>, DB::Decimal, long, long, DB::Decimal, DB::Decimal>(long, long, DB::Decimal, DB::Decimal) const requires !is_decimal && !is_decimal @ 0x000000000b50b9ac 6. /build/src/Functions/FunctionBinaryArithmetic.h:1560: COW::immutable_ptr DB::FunctionBinaryArithmetic::executeNumericWithDecimal, DB::DataTypeDecimal>, DB::DataTypeDecimal>, DB::DataTypeNumber, DB::DataTypeDecimal>, DB::ColumnVector, DB::ColumnDecimal>>(DB::DataTypeNumber const&, DB::DataTypeDecimal> const&, DB::ColumnConst const*, DB::ColumnConst const*, DB::ColumnVector const*, DB::ColumnDecimal> const*, unsigned long, DB::PODArray, 63ul, 64ul> const*) const @ 0x000000000b50b54d 7. /build/src/Functions/FunctionBinaryArithmetic.h:2270: COW::immutable_ptr DB::FunctionBinaryArithmetic::executeNumeric, DB::DataTypeDecimal>>(std::vector> const&, DB::DataTypeNumber const&, DB::DataTypeDecimal> const&, DB::PODArray, 63ul, 64ul> const*) const @ 0x000000000b50b244 8. /build/src/Functions/FunctionBinaryArithmetic.h:2508: auto auto bool DB::FunctionBinaryArithmetic::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&)::operator()>>(auto const&) const @ 0x000000000b505467 9. /build/src/Functions/castTypeToEither.h:18: 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&&) @ 0x000000000b504fb0 10. /build/src/Functions/FunctionBinaryArithmetic.h:846: 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&&) @ 0x000000000b503e07 11. /build/src/Functions/FunctionBinaryArithmetic.h:844: DB::FunctionBinaryArithmetic::executeImpl2(std::vector> const&, std::shared_ptr const&, unsigned long, DB::PODArray, 63ul, 64ul> const*) const @ 0x000000000b500305 12. /build/src/Functions/FunctionBinaryArithmetic.h:2410: DB::FunctionBinaryArithmetic::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000b4fe88c 13. /build/src/Functions/FunctionBinaryArithmetic.h:2645: DB::FunctionBinaryArithmeticWithConstants::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000b4fd634 14. /build/src/Functions/IFunction.h:437: DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000a069f2a 15. /build/src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000012d9965a 16. /build/src/Functions/IFunction.cpp:351: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d93b02 17. /build/src/Functions/IFunction.cpp:420: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d95059 18. /build/src/Functions/IFunction.cpp:498: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d95c72 19. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3567: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000014034494 20. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3838: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000014019a9e 21. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3980: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000014018e31 22. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:4304: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000014042fa7 23. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5605: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000014013749 24. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000140127f9 25. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000014011fce 26. /build/src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000001406ce8a 27. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000014973b42 28. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000001497268d 29. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000014974d24 30. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001492924b 31. /build/src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88641 2025.07.28 11:53:26.748502 [ 5112 ] {867e6bcf-110d-48b1-b93e-03cb0093bbd3} executeQuery: Code: 153. DB::Exception: Division by zero: In scope SELECT 1 / toDecimal128(0, 2). (ILLEGAL_DIVISION) (version 25.3.6.10636.altinitytest (altinity build)) (from [::1]:48688) (comment: 00700_decimal_arithm.sql) (query 45, line 72) (in query: SELECT 1 / toDecimal128(0, 2);), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000000a074fcb 4. /build/src/Functions/DivisionUtils.h:26: void DB::throwIfDivisionLeadsToFPE, wide::integer<128ul, int>>(wide::integer<128ul, int>, wide::integer<128ul, int>) @ 0x000000000b30d62f 5. /build/base/base/../base/wide_integer_impl.h:0: DB::Decimal> DB::FunctionBinaryArithmetic::helperInvokeEither>, false>, DB::impl_::DecimalBinaryOperation>, true>, DB::Decimal>, wide::integer<128ul, int>, wide::integer<128ul, int>, DB::Decimal>, DB::Decimal>>(wide::integer<128ul, int>, wide::integer<128ul, int>, DB::Decimal>, DB::Decimal>) const requires !is_decimal && !is_decimal @ 0x000000000b50c4d9 6. /build/src/Functions/FunctionBinaryArithmetic.h:1560: COW::immutable_ptr DB::FunctionBinaryArithmetic::executeNumericWithDecimal, DB::DataTypeDecimal>>, DB::DataTypeDecimal>>, DB::DataTypeNumber, DB::DataTypeDecimal>>, DB::ColumnVector, DB::ColumnDecimal>>>(DB::DataTypeNumber const&, DB::DataTypeDecimal>> const&, DB::ColumnConst const*, DB::ColumnConst const*, DB::ColumnVector const*, DB::ColumnDecimal>> const*, unsigned long, DB::PODArray, 63ul, 64ul> const*) const @ 0x000000000b50bf7d 7. /build/src/Functions/FunctionBinaryArithmetic.h:2270: COW::immutable_ptr DB::FunctionBinaryArithmetic::executeNumeric, DB::DataTypeDecimal>>>(std::vector> const&, DB::DataTypeNumber const&, DB::DataTypeDecimal>> const&, DB::PODArray, 63ul, 64ul> const*) const @ 0x000000000b50bbe4 8. /build/src/Functions/FunctionBinaryArithmetic.h:2508: auto auto bool DB::FunctionBinaryArithmetic::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&)::operator()>>>(auto const&) const @ 0x000000000b5054e7 9. /build/src/Functions/castTypeToEither.h:18: 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&&) @ 0x000000000b504ff8 10. /build/src/Functions/FunctionBinaryArithmetic.h:846: 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&&) @ 0x000000000b503e07 11. /build/src/Functions/FunctionBinaryArithmetic.h:844: DB::FunctionBinaryArithmetic::executeImpl2(std::vector> const&, std::shared_ptr const&, unsigned long, DB::PODArray, 63ul, 64ul> const*) const @ 0x000000000b500305 12. /build/src/Functions/FunctionBinaryArithmetic.h:2410: DB::FunctionBinaryArithmetic::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000b4fe88c 13. /build/src/Functions/FunctionBinaryArithmetic.h:2645: DB::FunctionBinaryArithmeticWithConstants::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000b4fd634 14. /build/src/Functions/IFunction.h:437: DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000a069f2a 15. /build/src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000012d9965a 16. /build/src/Functions/IFunction.cpp:351: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d93b02 17. /build/src/Functions/IFunction.cpp:420: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d95059 18. /build/src/Functions/IFunction.cpp:498: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d95c72 19. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3567: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000014034494 20. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3838: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000014019a9e 21. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3980: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000014018e31 22. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:4304: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000014042fa7 23. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5605: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000014013749 24. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000140127f9 25. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000014011fce 26. /build/src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000001406ce8a 27. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000014973b42 28. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000001497268d 29. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000014974d24 30. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001492924b 31. /build/src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88641 2025.07.28 11:53:26.824087 [ 5112 ] {} TCPHandler: Code: 153. DB::Exception: Division by zero: In scope SELECT 1 / toDecimal128(0, 2). (ILLEGAL_DIVISION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000000a074fcb 4. /build/src/Functions/DivisionUtils.h:26: void DB::throwIfDivisionLeadsToFPE, wide::integer<128ul, int>>(wide::integer<128ul, int>, wide::integer<128ul, int>) @ 0x000000000b30d62f 5. /build/base/base/../base/wide_integer_impl.h:0: DB::Decimal> DB::FunctionBinaryArithmetic::helperInvokeEither>, false>, DB::impl_::DecimalBinaryOperation>, true>, DB::Decimal>, wide::integer<128ul, int>, wide::integer<128ul, int>, DB::Decimal>, DB::Decimal>>(wide::integer<128ul, int>, wide::integer<128ul, int>, DB::Decimal>, DB::Decimal>) const requires !is_decimal && !is_decimal @ 0x000000000b50c4d9 6. /build/src/Functions/FunctionBinaryArithmetic.h:1560: COW::immutable_ptr DB::FunctionBinaryArithmetic::executeNumericWithDecimal, DB::DataTypeDecimal>>, DB::DataTypeDecimal>>, DB::DataTypeNumber, DB::DataTypeDecimal>>, DB::ColumnVector, DB::ColumnDecimal>>>(DB::DataTypeNumber const&, DB::DataTypeDecimal>> const&, DB::ColumnConst const*, DB::ColumnConst const*, DB::ColumnVector const*, DB::ColumnDecimal>> const*, unsigned long, DB::PODArray, 63ul, 64ul> const*) const @ 0x000000000b50bf7d 7. /build/src/Functions/FunctionBinaryArithmetic.h:2270: COW::immutable_ptr DB::FunctionBinaryArithmetic::executeNumeric, DB::DataTypeDecimal>>>(std::vector> const&, DB::DataTypeNumber const&, DB::DataTypeDecimal>> const&, DB::PODArray, 63ul, 64ul> const*) const @ 0x000000000b50bbe4 8. /build/src/Functions/FunctionBinaryArithmetic.h:2508: auto auto bool DB::FunctionBinaryArithmetic::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&)::operator()>>>(auto const&) const @ 0x000000000b5054e7 9. /build/src/Functions/castTypeToEither.h:18: 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&&) @ 0x000000000b504ff8 10. /build/src/Functions/FunctionBinaryArithmetic.h:846: 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&&) @ 0x000000000b503e07 11. /build/src/Functions/FunctionBinaryArithmetic.h:844: DB::FunctionBinaryArithmetic::executeImpl2(std::vector> const&, std::shared_ptr const&, unsigned long, DB::PODArray, 63ul, 64ul> const*) const @ 0x000000000b500305 12. /build/src/Functions/FunctionBinaryArithmetic.h:2410: DB::FunctionBinaryArithmetic::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000b4fe88c 13. /build/src/Functions/FunctionBinaryArithmetic.h:2645: DB::FunctionBinaryArithmeticWithConstants::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000b4fd634 14. /build/src/Functions/IFunction.h:437: DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000a069f2a 15. /build/src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000012d9965a 16. /build/src/Functions/IFunction.cpp:351: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d93b02 17. /build/src/Functions/IFunction.cpp:420: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d95059 18. /build/src/Functions/IFunction.cpp:498: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d95c72 19. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3567: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000014034494 20. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3838: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000014019a9e 21. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3980: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000014018e31 22. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:4304: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000014042fa7 23. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5605: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000014013749 24. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000140127f9 25. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000014011fce 26. /build/src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000001406ce8a 27. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000014973b42 28. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000001497268d 29. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000014974d24 30. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001492924b 31. /build/src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88641 2025.07.28 11:53:26.858092 [ 5112 ] {131a0b6a-7fb0-4ee7-901e-eaa30e111765} executeQuery: Code: 153. DB::Exception: Division by zero: In scope SELECT 0 / toDecimal32(0, 3). (ILLEGAL_DIVISION) (version 25.3.6.10636.altinitytest (altinity build)) (from [::1]:48688) (comment: 00700_decimal_arithm.sql) (query 46, line 73) (in query: SELECT 0 / toDecimal32(0, 3);), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000000a074fcb 4. /build/src/Functions/DivisionUtils.h:26: void DB::throwIfDivisionLeadsToFPE(int, int) @ 0x000000000b309e93 5. /build/src/Functions/FunctionBinaryArithmetic.h:0: DB::Decimal DB::FunctionBinaryArithmetic::helperInvokeEither, false>, DB::impl_::DecimalBinaryOperation, true>, DB::Decimal, int, int, DB::Decimal, DB::Decimal>(int, int, DB::Decimal, DB::Decimal) const requires !is_decimal && !is_decimal @ 0x000000000b50b01f 6. /build/src/Functions/FunctionBinaryArithmetic.h:1560: COW::immutable_ptr DB::FunctionBinaryArithmetic::executeNumericWithDecimal, DB::DataTypeDecimal>, DB::DataTypeDecimal>, DB::DataTypeNumber, DB::DataTypeDecimal>, DB::ColumnVector, DB::ColumnDecimal>>(DB::DataTypeNumber const&, DB::DataTypeDecimal> const&, DB::ColumnConst const*, DB::ColumnConst const*, DB::ColumnVector const*, DB::ColumnDecimal> const*, unsigned long, DB::PODArray, 63ul, 64ul> const*) const @ 0x000000000b50aaf1 7. /build/src/Functions/FunctionBinaryArithmetic.h:2270: COW::immutable_ptr DB::FunctionBinaryArithmetic::executeNumeric, DB::DataTypeDecimal>>(std::vector> const&, DB::DataTypeNumber const&, DB::DataTypeDecimal> const&, DB::PODArray, 63ul, 64ul> const*) const @ 0x000000000b50a8e4 8. /build/src/Functions/FunctionBinaryArithmetic.h:2508: auto auto bool DB::FunctionBinaryArithmetic::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&)::operator()>>(auto const&) const @ 0x000000000b5053e7 9. /build/src/Functions/castTypeToEither.h:18: 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&&) @ 0x000000000b504f67 10. /build/src/Functions/FunctionBinaryArithmetic.h:846: 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&&) @ 0x000000000b503e07 11. /build/src/Functions/FunctionBinaryArithmetic.h:844: DB::FunctionBinaryArithmetic::executeImpl2(std::vector> const&, std::shared_ptr const&, unsigned long, DB::PODArray, 63ul, 64ul> const*) const @ 0x000000000b500305 12. /build/src/Functions/FunctionBinaryArithmetic.h:2410: DB::FunctionBinaryArithmetic::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000b4fe88c 13. /build/src/Functions/FunctionBinaryArithmetic.h:2645: DB::FunctionBinaryArithmeticWithConstants::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000b4fd634 14. /build/src/Functions/IFunction.h:437: DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000a069f2a 15. /build/src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000012d9965a 16. /build/src/Functions/IFunction.cpp:351: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d93b02 17. /build/src/Functions/IFunction.cpp:420: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d95059 18. /build/src/Functions/IFunction.cpp:498: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d95c72 19. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3567: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000014034494 20. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3838: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000014019a9e 21. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3980: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000014018e31 22. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:4304: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000014042fa7 23. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5605: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000014013749 24. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000140127f9 25. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000014011fce 26. /build/src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000001406ce8a 27. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000014973b42 28. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000001497268d 29. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000014974d24 30. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001492924b 31. /build/src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88641 2025.07.28 11:53:26.870270 [ 5112 ] {} TCPHandler: Code: 153. DB::Exception: Division by zero: In scope SELECT 0 / toDecimal32(0, 3). (ILLEGAL_DIVISION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000000a074fcb 4. /build/src/Functions/DivisionUtils.h:26: void DB::throwIfDivisionLeadsToFPE(int, int) @ 0x000000000b309e93 5. /build/src/Functions/FunctionBinaryArithmetic.h:0: DB::Decimal DB::FunctionBinaryArithmetic::helperInvokeEither, false>, DB::impl_::DecimalBinaryOperation, true>, DB::Decimal, int, int, DB::Decimal, DB::Decimal>(int, int, DB::Decimal, DB::Decimal) const requires !is_decimal && !is_decimal @ 0x000000000b50b01f 6. /build/src/Functions/FunctionBinaryArithmetic.h:1560: COW::immutable_ptr DB::FunctionBinaryArithmetic::executeNumericWithDecimal, DB::DataTypeDecimal>, DB::DataTypeDecimal>, DB::DataTypeNumber, DB::DataTypeDecimal>, DB::ColumnVector, DB::ColumnDecimal>>(DB::DataTypeNumber const&, DB::DataTypeDecimal> const&, DB::ColumnConst const*, DB::ColumnConst const*, DB::ColumnVector const*, DB::ColumnDecimal> const*, unsigned long, DB::PODArray, 63ul, 64ul> const*) const @ 0x000000000b50aaf1 7. /build/src/Functions/FunctionBinaryArithmetic.h:2270: COW::immutable_ptr DB::FunctionBinaryArithmetic::executeNumeric, DB::DataTypeDecimal>>(std::vector> const&, DB::DataTypeNumber const&, DB::DataTypeDecimal> const&, DB::PODArray, 63ul, 64ul> const*) const @ 0x000000000b50a8e4 8. /build/src/Functions/FunctionBinaryArithmetic.h:2508: auto auto bool DB::FunctionBinaryArithmetic::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&)::operator()>>(auto const&) const @ 0x000000000b5053e7 9. /build/src/Functions/castTypeToEither.h:18: 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&&) @ 0x000000000b504f67 10. /build/src/Functions/FunctionBinaryArithmetic.h:846: 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&&) @ 0x000000000b503e07 11. /build/src/Functions/FunctionBinaryArithmetic.h:844: DB::FunctionBinaryArithmetic::executeImpl2(std::vector> const&, std::shared_ptr const&, unsigned long, DB::PODArray, 63ul, 64ul> const*) const @ 0x000000000b500305 12. /build/src/Functions/FunctionBinaryArithmetic.h:2410: DB::FunctionBinaryArithmetic::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000b4fe88c 13. /build/src/Functions/FunctionBinaryArithmetic.h:2645: DB::FunctionBinaryArithmeticWithConstants::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000b4fd634 14. /build/src/Functions/IFunction.h:437: DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000a069f2a 15. /build/src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000012d9965a 16. /build/src/Functions/IFunction.cpp:351: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d93b02 17. /build/src/Functions/IFunction.cpp:420: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d95059 18. /build/src/Functions/IFunction.cpp:498: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d95c72 19. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3567: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000014034494 20. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3838: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000014019a9e 21. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3980: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000014018e31 22. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:4304: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000014042fa7 23. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5605: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000014013749 24. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000140127f9 25. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000014011fce 26. /build/src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000001406ce8a 27. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000014973b42 28. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000001497268d 29. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000014974d24 30. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001492924b 31. /build/src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88641 2025.07.28 11:53:26.875961 [ 17287 ] {d9a485dc-c9cf-43e7-8ad7-41523b3d414b} executeQuery: Code: 407. DB::Exception: Numeric overflow: In scope SELECT addMinutes(toDateTime('2021-01-01 00:00:00', 'GMT'), 9223372036854775808). (DECIMAL_OVERFLOW) (version 25.3.6.10636.altinitytest (altinity build)) (from [::1]:51276) (comment: 01662_date_ubsan.sql) (query 6, line 7) (in query: -- tests with INT64_MIN (via overflow) SELECT addMinutes(toDateTime('2021-01-01 00:00:00', 'GMT'), 9223372036854775808);), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000000a074fcb 4. /build/src/Functions/FunctionDateOrDateTimeAddInterval.h:486: void DB::Processor::vectorVector, DB::ColumnVector, DB::ColumnVector>(DB::ColumnVector const&, DB::ColumnVector&, DB::ColumnVector const&, DateLUTImpl const&, unsigned short, unsigned long) const @ 0x000000000aa37f18 5. /build/src/Functions/FunctionDateOrDateTimeAddInterval.h:466: void DB::Processor::vectorVector, DB::ColumnVector>(DB::ColumnVector const&, DB::ColumnVector&, DB::IColumn const&, DateLUTImpl const&, unsigned short, unsigned long) const @ 0x000000000aa3745f 6. /build/src/Functions/FunctionDateOrDateTimeAddInterval.h:559: DB::DateTimeAddIntervalImpl::execute(DB::AddMinutesImpl, std::vector> const&, std::shared_ptr const&, unsigned short, unsigned long) @ 0x000000000aa302d1 7. /build/src/Functions/FunctionDateOrDateTimeAddInterval.h:715: DB::FunctionDateOrDateTimeAddInterval::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000aa2ef59 8. /build/src/Functions/IFunction.h:437: DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000a069f2a 9. /build/src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000012d9965a 10. /build/src/Functions/IFunction.cpp:351: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d93b02 11. /build/src/Functions/IFunction.cpp:177: DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d93698 12. /build/src/Functions/IFunction.cpp:343: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d93aad 13. /build/src/Functions/IFunction.cpp:420: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d95059 14. /build/src/Functions/IFunction.cpp:498: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d95c72 15. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3567: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000014034494 16. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3838: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000014019a9e 17. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3980: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000014018e31 18. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:4304: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000014042fa7 19. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5605: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000014013749 20. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000140127f9 21. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000014011fce 22. /build/src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000001406ce8a 23. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000014973b42 24. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000001497268d 25. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000014974d24 26. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001492924b 27. /build/src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88641 28. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 29. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 30. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 31. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 2025.07.28 11:53:26.891073 [ 17287 ] {} TCPHandler: Code: 407. DB::Exception: Numeric overflow: In scope SELECT addMinutes(toDateTime('2021-01-01 00:00:00', 'GMT'), 9223372036854775808). (DECIMAL_OVERFLOW), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000000a074fcb 4. /build/src/Functions/FunctionDateOrDateTimeAddInterval.h:486: void DB::Processor::vectorVector, DB::ColumnVector, DB::ColumnVector>(DB::ColumnVector const&, DB::ColumnVector&, DB::ColumnVector const&, DateLUTImpl const&, unsigned short, unsigned long) const @ 0x000000000aa37f18 5. /build/src/Functions/FunctionDateOrDateTimeAddInterval.h:466: void DB::Processor::vectorVector, DB::ColumnVector>(DB::ColumnVector const&, DB::ColumnVector&, DB::IColumn const&, DateLUTImpl const&, unsigned short, unsigned long) const @ 0x000000000aa3745f 6. /build/src/Functions/FunctionDateOrDateTimeAddInterval.h:559: DB::DateTimeAddIntervalImpl::execute(DB::AddMinutesImpl, std::vector> const&, std::shared_ptr const&, unsigned short, unsigned long) @ 0x000000000aa302d1 7. /build/src/Functions/FunctionDateOrDateTimeAddInterval.h:715: DB::FunctionDateOrDateTimeAddInterval::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000aa2ef59 8. /build/src/Functions/IFunction.h:437: DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000a069f2a 9. /build/src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000012d9965a 10. /build/src/Functions/IFunction.cpp:351: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d93b02 11. /build/src/Functions/IFunction.cpp:177: DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d93698 12. /build/src/Functions/IFunction.cpp:343: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d93aad 13. /build/src/Functions/IFunction.cpp:420: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d95059 14. /build/src/Functions/IFunction.cpp:498: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d95c72 15. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3567: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000014034494 16. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3838: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000014019a9e 17. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3980: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000014018e31 18. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:4304: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000014042fa7 19. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5605: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000014013749 20. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000140127f9 21. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000014011fce 22. /build/src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000001406ce8a 23. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000014973b42 24. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000001497268d 25. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000014974d24 26. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001492924b 27. /build/src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88641 28. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 29. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 30. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 31. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 2025.07.28 11:53:26.939929 [ 3961 ] {} test_13.rmt2 (7f9b740d-015c-470e-8cc6-8ba33be0dc63): auto DB::StorageReplicatedMergeTree::processQueueEntry(ReplicatedMergeTreeQueue::SelectedEntryPtr)::(anonymous class)::operator()(LogEntryPtr &) const: Code: 86. DB::HTTPException: Received error from remote server http://146b4357c08d:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Ftest%2F01165%2Ftest_13%2Frmt%2Freplicas%2F1&part=20250728_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.6.10636.altinitytest (altinity build)) '. (RECEIVED_ERROR_FROM_REMOTE_IO_SERVER), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.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 const&, int&&, String const&, unsigned long&&, String const&) @ 0x000000000feda8d9 4. /build/src/IO/HTTPCommon.cpp:104: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x000000000feda6e2 5. /build/src/IO/HTTPCommon.cpp:93: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x000000000feda537 6. /build/src/IO/ReadWriteBufferFromHTTP.cpp:277: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x000000001184a4c4 7. /build/src/IO/ReadWriteBufferFromHTTP.cpp:285: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x000000001184a615 8. /build/src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x000000001184ae59 9. /build/src/IO/ReadWriteBufferFromHTTP.cpp:472: void std::__function::__policy_invoker::__call_impl[abi:se190107]>(std::__function::__policy_storage const*) @ 0x000000001184cedd 10. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001184858b 11. /build/src/IO/ReadWriteBufferFromHTTP.cpp:465: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x000000001184bf0b 12. /build/src/IO/ReadBuffer.h:60: DB::ReadBuffer::next() @ 0x000000000a148c7b 13. /build/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) @ 0x0000000011849fb2 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]>&)>&, 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&) @ 0x0000000011841980 15. /build/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) @ 0x000000001621208e 16. /build/src/Storages/StorageReplicatedMergeTree.cpp:5228: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl[abi:se190107] const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000015f9a5fe 17. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000015ed8bfd 18. /build/src/Storages/StorageReplicatedMergeTree.cpp:2514: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x0000000015ec9aab 19. /build/src/Storages/StorageReplicatedMergeTree.cpp:2349: DB::StorageReplicatedMergeTree::executeLogEntry(DB::ReplicatedMergeTreeLogEntry&) @ 0x0000000015eba91b 20. /build/src/Storages/StorageReplicatedMergeTree.cpp:3876: bool std::__function::__policy_invoker&)>::__call_impl[abi:se190107])::$_1, bool (std::shared_ptr&)>>(std::__function::__policy_storage const*, std::shared_ptr&) @ 0x0000000015f9837e 21. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000165d6fc3 22. /build/src/Storages/StorageReplicatedMergeTree.cpp:3872: DB::StorageReplicatedMergeTree::processQueueEntry(std::shared_ptr) @ 0x0000000015efc18a 23. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001624c1b2 24. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000162f9c70 25. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x00000000162fa55a 26. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc6653 27. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000000fccc4c3 28. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc3d92 29. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fcca080 30. ? @ 0x00007fbc6213eac3 31. ? @ 0x00007fbc621d0850 (version 25.3.6.10636.altinitytest (altinity build)) 2025.07.28 11:53:26.951011 [ 5112 ] {186c1c96-80b8-4c30-ac93-a53194f876e2} executeQuery: Code: 153. DB::Exception: Division by zero: In scope SELECT 0 / toDecimal64(0, 4). (ILLEGAL_DIVISION) (version 25.3.6.10636.altinitytest (altinity build)) (from [::1]:48688) (comment: 00700_decimal_arithm.sql) (query 47, line 74) (in query: SELECT 0 / toDecimal64(0, 4);), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000000a074fcb 4. /build/src/Functions/DivisionUtils.h:26: void DB::throwIfDivisionLeadsToFPE(long, long) @ 0x000000000b2fd11e 5. /build/src/Functions/FunctionBinaryArithmetic.h:0: DB::Decimal DB::FunctionBinaryArithmetic::helperInvokeEither, false>, DB::impl_::DecimalBinaryOperation, true>, DB::Decimal, long, long, DB::Decimal, DB::Decimal>(long, long, DB::Decimal, DB::Decimal) const requires !is_decimal && !is_decimal @ 0x000000000b50b9ac 6. /build/src/Functions/FunctionBinaryArithmetic.h:1560: COW::immutable_ptr DB::FunctionBinaryArithmetic::executeNumericWithDecimal, DB::DataTypeDecimal>, DB::DataTypeDecimal>, DB::DataTypeNumber, DB::DataTypeDecimal>, DB::ColumnVector, DB::ColumnDecimal>>(DB::DataTypeNumber const&, DB::DataTypeDecimal> const&, DB::ColumnConst const*, DB::ColumnConst const*, DB::ColumnVector const*, DB::ColumnDecimal> const*, unsigned long, DB::PODArray, 63ul, 64ul> const*) const @ 0x000000000b50b54d 7. /build/src/Functions/FunctionBinaryArithmetic.h:2270: COW::immutable_ptr DB::FunctionBinaryArithmetic::executeNumeric, DB::DataTypeDecimal>>(std::vector> const&, DB::DataTypeNumber const&, DB::DataTypeDecimal> const&, DB::PODArray, 63ul, 64ul> const*) const @ 0x000000000b50b244 8. /build/src/Functions/FunctionBinaryArithmetic.h:2508: auto auto bool DB::FunctionBinaryArithmetic::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&)::operator()>>(auto const&) const @ 0x000000000b505467 9. /build/src/Functions/castTypeToEither.h:18: 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&&) @ 0x000000000b504fb0 10. /build/src/Functions/FunctionBinaryArithmetic.h:846: 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&&) @ 0x000000000b503e07 11. /build/src/Functions/FunctionBinaryArithmetic.h:844: DB::FunctionBinaryArithmetic::executeImpl2(std::vector> const&, std::shared_ptr const&, unsigned long, DB::PODArray, 63ul, 64ul> const*) const @ 0x000000000b500305 12. /build/src/Functions/FunctionBinaryArithmetic.h:2410: DB::FunctionBinaryArithmetic::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000b4fe88c 13. /build/src/Functions/FunctionBinaryArithmetic.h:2645: DB::FunctionBinaryArithmeticWithConstants::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000b4fd634 14. /build/src/Functions/IFunction.h:437: DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000a069f2a 15. /build/src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000012d9965a 16. /build/src/Functions/IFunction.cpp:351: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d93b02 17. /build/src/Functions/IFunction.cpp:420: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d95059 18. /build/src/Functions/IFunction.cpp:498: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d95c72 19. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3567: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000014034494 20. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3838: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000014019a9e 21. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3980: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000014018e31 22. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:4304: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000014042fa7 23. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5605: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000014013749 24. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000140127f9 25. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000014011fce 26. /build/src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000001406ce8a 27. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000014973b42 28. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000001497268d 29. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000014974d24 30. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001492924b 31. /build/src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88641 2025.07.28 11:53:26.970326 [ 5112 ] {} TCPHandler: Code: 153. DB::Exception: Division by zero: In scope SELECT 0 / toDecimal64(0, 4). (ILLEGAL_DIVISION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000000a074fcb 4. /build/src/Functions/DivisionUtils.h:26: void DB::throwIfDivisionLeadsToFPE(long, long) @ 0x000000000b2fd11e 5. /build/src/Functions/FunctionBinaryArithmetic.h:0: DB::Decimal DB::FunctionBinaryArithmetic::helperInvokeEither, false>, DB::impl_::DecimalBinaryOperation, true>, DB::Decimal, long, long, DB::Decimal, DB::Decimal>(long, long, DB::Decimal, DB::Decimal) const requires !is_decimal && !is_decimal @ 0x000000000b50b9ac 6. /build/src/Functions/FunctionBinaryArithmetic.h:1560: COW::immutable_ptr DB::FunctionBinaryArithmetic::executeNumericWithDecimal, DB::DataTypeDecimal>, DB::DataTypeDecimal>, DB::DataTypeNumber, DB::DataTypeDecimal>, DB::ColumnVector, DB::ColumnDecimal>>(DB::DataTypeNumber const&, DB::DataTypeDecimal> const&, DB::ColumnConst const*, DB::ColumnConst const*, DB::ColumnVector const*, DB::ColumnDecimal> const*, unsigned long, DB::PODArray, 63ul, 64ul> const*) const @ 0x000000000b50b54d 7. /build/src/Functions/FunctionBinaryArithmetic.h:2270: COW::immutable_ptr DB::FunctionBinaryArithmetic::executeNumeric, DB::DataTypeDecimal>>(std::vector> const&, DB::DataTypeNumber const&, DB::DataTypeDecimal> const&, DB::PODArray, 63ul, 64ul> const*) const @ 0x000000000b50b244 8. /build/src/Functions/FunctionBinaryArithmetic.h:2508: auto auto bool DB::FunctionBinaryArithmetic::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&)::operator()>>(auto const&) const @ 0x000000000b505467 9. /build/src/Functions/castTypeToEither.h:18: 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&&) @ 0x000000000b504fb0 10. /build/src/Functions/FunctionBinaryArithmetic.h:846: 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&&) @ 0x000000000b503e07 11. /build/src/Functions/FunctionBinaryArithmetic.h:844: DB::FunctionBinaryArithmetic::executeImpl2(std::vector> const&, std::shared_ptr const&, unsigned long, DB::PODArray, 63ul, 64ul> const*) const @ 0x000000000b500305 12. /build/src/Functions/FunctionBinaryArithmetic.h:2410: DB::FunctionBinaryArithmetic::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000b4fe88c 13. /build/src/Functions/FunctionBinaryArithmetic.h:2645: DB::FunctionBinaryArithmeticWithConstants::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000b4fd634 14. /build/src/Functions/IFunction.h:437: DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000a069f2a 15. /build/src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000012d9965a 16. /build/src/Functions/IFunction.cpp:351: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d93b02 17. /build/src/Functions/IFunction.cpp:420: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d95059 18. /build/src/Functions/IFunction.cpp:498: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d95c72 19. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3567: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000014034494 20. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3838: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000014019a9e 21. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3980: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000014018e31 22. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:4304: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000014042fa7 23. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5605: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000014013749 24. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000140127f9 25. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000014011fce 26. /build/src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000001406ce8a 27. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000014973b42 28. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000001497268d 29. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000014974d24 30. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001492924b 31. /build/src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88641 2025.07.28 11:53:27.008500 [ 5112 ] {fadbc750-5c96-4c4a-beb7-db1e8f4ac999} executeQuery: Code: 153. DB::Exception: Division by zero: In scope SELECT 0 / toDecimal128(0, 5). (ILLEGAL_DIVISION) (version 25.3.6.10636.altinitytest (altinity build)) (from [::1]:48688) (comment: 00700_decimal_arithm.sql) (query 48, line 75) (in query: SELECT 0 / toDecimal128(0, 5);), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000000a074fcb 4. /build/src/Functions/DivisionUtils.h:26: void DB::throwIfDivisionLeadsToFPE, wide::integer<128ul, int>>(wide::integer<128ul, int>, wide::integer<128ul, int>) @ 0x000000000b30d62f 5. /build/base/base/../base/wide_integer_impl.h:0: DB::Decimal> DB::FunctionBinaryArithmetic::helperInvokeEither>, false>, DB::impl_::DecimalBinaryOperation>, true>, DB::Decimal>, wide::integer<128ul, int>, wide::integer<128ul, int>, DB::Decimal>, DB::Decimal>>(wide::integer<128ul, int>, wide::integer<128ul, int>, DB::Decimal>, DB::Decimal>) const requires !is_decimal && !is_decimal @ 0x000000000b50c4d9 6. /build/src/Functions/FunctionBinaryArithmetic.h:1560: COW::immutable_ptr DB::FunctionBinaryArithmetic::executeNumericWithDecimal, DB::DataTypeDecimal>>, DB::DataTypeDecimal>>, DB::DataTypeNumber, DB::DataTypeDecimal>>, DB::ColumnVector, DB::ColumnDecimal>>>(DB::DataTypeNumber const&, DB::DataTypeDecimal>> const&, DB::ColumnConst const*, DB::ColumnConst const*, DB::ColumnVector const*, DB::ColumnDecimal>> const*, unsigned long, DB::PODArray, 63ul, 64ul> const*) const @ 0x000000000b50bf7d 7. /build/src/Functions/FunctionBinaryArithmetic.h:2270: COW::immutable_ptr DB::FunctionBinaryArithmetic::executeNumeric, DB::DataTypeDecimal>>>(std::vector> const&, DB::DataTypeNumber const&, DB::DataTypeDecimal>> const&, DB::PODArray, 63ul, 64ul> const*) const @ 0x000000000b50bbe4 8. /build/src/Functions/FunctionBinaryArithmetic.h:2508: auto auto bool DB::FunctionBinaryArithmetic::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&)::operator()>>>(auto const&) const @ 0x000000000b5054e7 9. /build/src/Functions/castTypeToEither.h:18: 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&&) @ 0x000000000b504ff8 10. /build/src/Functions/FunctionBinaryArithmetic.h:846: 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&&) @ 0x000000000b503e07 11. /build/src/Functions/FunctionBinaryArithmetic.h:844: DB::FunctionBinaryArithmetic::executeImpl2(std::vector> const&, std::shared_ptr const&, unsigned long, DB::PODArray, 63ul, 64ul> const*) const @ 0x000000000b500305 12. /build/src/Functions/FunctionBinaryArithmetic.h:2410: DB::FunctionBinaryArithmetic::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000b4fe88c 13. /build/src/Functions/FunctionBinaryArithmetic.h:2645: DB::FunctionBinaryArithmeticWithConstants::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000b4fd634 14. /build/src/Functions/IFunction.h:437: DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000a069f2a 15. /build/src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000012d9965a 16. /build/src/Functions/IFunction.cpp:351: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d93b02 17. /build/src/Functions/IFunction.cpp:420: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d95059 18. /build/src/Functions/IFunction.cpp:498: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d95c72 19. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3567: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000014034494 20. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3838: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000014019a9e 21. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3980: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000014018e31 22. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:4304: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000014042fa7 23. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5605: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000014013749 24. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000140127f9 25. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000014011fce 26. /build/src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000001406ce8a 27. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000014973b42 28. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000001497268d 29. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000014974d24 30. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001492924b 31. /build/src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88641 2025.07.28 11:53:27.014206 [ 5112 ] {} TCPHandler: Code: 153. DB::Exception: Division by zero: In scope SELECT 0 / toDecimal128(0, 5). (ILLEGAL_DIVISION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000000a074fcb 4. /build/src/Functions/DivisionUtils.h:26: void DB::throwIfDivisionLeadsToFPE, wide::integer<128ul, int>>(wide::integer<128ul, int>, wide::integer<128ul, int>) @ 0x000000000b30d62f 5. /build/base/base/../base/wide_integer_impl.h:0: DB::Decimal> DB::FunctionBinaryArithmetic::helperInvokeEither>, false>, DB::impl_::DecimalBinaryOperation>, true>, DB::Decimal>, wide::integer<128ul, int>, wide::integer<128ul, int>, DB::Decimal>, DB::Decimal>>(wide::integer<128ul, int>, wide::integer<128ul, int>, DB::Decimal>, DB::Decimal>) const requires !is_decimal && !is_decimal @ 0x000000000b50c4d9 6. /build/src/Functions/FunctionBinaryArithmetic.h:1560: COW::immutable_ptr DB::FunctionBinaryArithmetic::executeNumericWithDecimal, DB::DataTypeDecimal>>, DB::DataTypeDecimal>>, DB::DataTypeNumber, DB::DataTypeDecimal>>, DB::ColumnVector, DB::ColumnDecimal>>>(DB::DataTypeNumber const&, DB::DataTypeDecimal>> const&, DB::ColumnConst const*, DB::ColumnConst const*, DB::ColumnVector const*, DB::ColumnDecimal>> const*, unsigned long, DB::PODArray, 63ul, 64ul> const*) const @ 0x000000000b50bf7d 7. /build/src/Functions/FunctionBinaryArithmetic.h:2270: COW::immutable_ptr DB::FunctionBinaryArithmetic::executeNumeric, DB::DataTypeDecimal>>>(std::vector> const&, DB::DataTypeNumber const&, DB::DataTypeDecimal>> const&, DB::PODArray, 63ul, 64ul> const*) const @ 0x000000000b50bbe4 8. /build/src/Functions/FunctionBinaryArithmetic.h:2508: auto auto bool DB::FunctionBinaryArithmetic::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&)::operator()>>>(auto const&) const @ 0x000000000b5054e7 9. /build/src/Functions/castTypeToEither.h:18: 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&&) @ 0x000000000b504ff8 10. /build/src/Functions/FunctionBinaryArithmetic.h:846: 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&&) @ 0x000000000b503e07 11. /build/src/Functions/FunctionBinaryArithmetic.h:844: DB::FunctionBinaryArithmetic::executeImpl2(std::vector> const&, std::shared_ptr const&, unsigned long, DB::PODArray, 63ul, 64ul> const*) const @ 0x000000000b500305 12. /build/src/Functions/FunctionBinaryArithmetic.h:2410: DB::FunctionBinaryArithmetic::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000b4fe88c 13. /build/src/Functions/FunctionBinaryArithmetic.h:2645: DB::FunctionBinaryArithmeticWithConstants::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000b4fd634 14. /build/src/Functions/IFunction.h:437: DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000a069f2a 15. /build/src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000012d9965a 16. /build/src/Functions/IFunction.cpp:351: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d93b02 17. /build/src/Functions/IFunction.cpp:420: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d95059 18. /build/src/Functions/IFunction.cpp:498: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d95c72 19. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3567: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000014034494 20. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3838: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000014019a9e 21. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3980: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000014018e31 22. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:4304: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000014042fa7 23. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5605: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000014013749 24. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000140127f9 25. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000014011fce 26. /build/src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000001406ce8a 27. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000014973b42 28. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000001497268d 29. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000014974d24 30. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001492924b 31. /build/src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88641 2025.07.28 11:53:27.040391 [ 17287 ] {dc5dbff6-572f-414e-aa70-ca3bb02adbbd} executeQuery: Code: 407. DB::Exception: Numeric overflow: In scope SELECT addHours(toDateTime('2021-01-01 00:00:00', 'GMT'), 9223372036854775808). (DECIMAL_OVERFLOW) (version 25.3.6.10636.altinitytest (altinity build)) (from [::1]:51276) (comment: 01662_date_ubsan.sql) (query 7, line 9) (in query: SELECT addHours(toDateTime('2021-01-01 00:00:00', 'GMT'), 9223372036854775808);), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000000a074fcb 4. /build/src/Functions/FunctionDateOrDateTimeAddInterval.h:486: void DB::Processor::vectorVector, DB::ColumnVector, DB::ColumnVector>(DB::ColumnVector const&, DB::ColumnVector&, DB::ColumnVector const&, DateLUTImpl const&, unsigned short, unsigned long) const @ 0x000000000aa006db 5. /build/src/Functions/FunctionDateOrDateTimeAddInterval.h:466: void DB::Processor::vectorVector, DB::ColumnVector>(DB::ColumnVector const&, DB::ColumnVector&, DB::IColumn const&, DateLUTImpl const&, unsigned short, unsigned long) const @ 0x000000000a9ffc1f 6. /build/src/Functions/FunctionDateOrDateTimeAddInterval.h:559: DB::DateTimeAddIntervalImpl::execute(DB::AddHoursImpl, std::vector> const&, std::shared_ptr const&, unsigned short, unsigned long) @ 0x000000000a9f89d1 7. /build/src/Functions/FunctionDateOrDateTimeAddInterval.h:715: DB::FunctionDateOrDateTimeAddInterval::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000a9f7659 8. /build/src/Functions/IFunction.h:437: DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000a069f2a 9. /build/src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000012d9965a 10. /build/src/Functions/IFunction.cpp:351: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d93b02 11. /build/src/Functions/IFunction.cpp:177: DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d93698 12. /build/src/Functions/IFunction.cpp:343: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d93aad 13. /build/src/Functions/IFunction.cpp:420: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d95059 14. /build/src/Functions/IFunction.cpp:498: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d95c72 15. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3567: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000014034494 16. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3838: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000014019a9e 17. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3980: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000014018e31 18. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:4304: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000014042fa7 19. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5605: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000014013749 20. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000140127f9 21. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000014011fce 22. /build/src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000001406ce8a 23. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000014973b42 24. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000001497268d 25. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000014974d24 26. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001492924b 27. /build/src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88641 28. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 29. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 30. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 31. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 2025.07.28 11:53:27.044476 [ 17287 ] {} TCPHandler: Code: 407. DB::Exception: Numeric overflow: In scope SELECT addHours(toDateTime('2021-01-01 00:00:00', 'GMT'), 9223372036854775808). (DECIMAL_OVERFLOW), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000000a074fcb 4. /build/src/Functions/FunctionDateOrDateTimeAddInterval.h:486: void DB::Processor::vectorVector, DB::ColumnVector, DB::ColumnVector>(DB::ColumnVector const&, DB::ColumnVector&, DB::ColumnVector const&, DateLUTImpl const&, unsigned short, unsigned long) const @ 0x000000000aa006db 5. /build/src/Functions/FunctionDateOrDateTimeAddInterval.h:466: void DB::Processor::vectorVector, DB::ColumnVector>(DB::ColumnVector const&, DB::ColumnVector&, DB::IColumn const&, DateLUTImpl const&, unsigned short, unsigned long) const @ 0x000000000a9ffc1f 6. /build/src/Functions/FunctionDateOrDateTimeAddInterval.h:559: DB::DateTimeAddIntervalImpl::execute(DB::AddHoursImpl, std::vector> const&, std::shared_ptr const&, unsigned short, unsigned long) @ 0x000000000a9f89d1 7. /build/src/Functions/FunctionDateOrDateTimeAddInterval.h:715: DB::FunctionDateOrDateTimeAddInterval::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000a9f7659 8. /build/src/Functions/IFunction.h:437: DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000a069f2a 9. /build/src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000012d9965a 10. /build/src/Functions/IFunction.cpp:351: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d93b02 11. /build/src/Functions/IFunction.cpp:177: DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d93698 12. /build/src/Functions/IFunction.cpp:343: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d93aad 13. /build/src/Functions/IFunction.cpp:420: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d95059 14. /build/src/Functions/IFunction.cpp:498: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d95c72 15. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3567: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000014034494 16. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3838: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000014019a9e 17. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3980: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000014018e31 18. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:4304: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000014042fa7 19. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5605: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000014013749 20. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000140127f9 21. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000014011fce 22. /build/src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000001406ce8a 23. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000014973b42 24. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000001497268d 25. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000014974d24 26. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001492924b 27. /build/src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88641 28. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 29. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 30. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 31. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 2025.07.28 11:53:27.137489 [ 17287 ] {5e0577af-25d8-47b4-97f6-7040f3b15d75} executeQuery: Code: 407. DB::Exception: Numeric overflow: In scope SELECT addWeeks(toDateTime('2021-01-01 00:00:00', 'GMT'), 9223372036854775808). (DECIMAL_OVERFLOW) (version 25.3.6.10636.altinitytest (altinity build)) (from [::1]:51276) (comment: 01662_date_ubsan.sql) (query 8, line 10) (in query: SELECT addWeeks(toDateTime('2021-01-01 00:00:00', 'GMT'), 9223372036854775808);), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000000a074fcb 4. /build/src/Functions/FunctionDateOrDateTimeAddInterval.h:486: void DB::Processor::vectorVector, DB::ColumnVector, DB::ColumnVector>(DB::ColumnVector const&, DB::ColumnVector&, DB::ColumnVector const&, DateLUTImpl const&, unsigned short, unsigned long) const @ 0x000000000aa9a9ad 5. /build/src/Functions/FunctionDateOrDateTimeAddInterval.h:466: void DB::Processor::vectorVector, DB::ColumnVector>(DB::ColumnVector const&, DB::ColumnVector&, DB::IColumn const&, DateLUTImpl const&, unsigned short, unsigned long) const @ 0x000000000aa99bbf 6. /build/src/Functions/FunctionDateOrDateTimeAddInterval.h:559: DB::DateTimeAddIntervalImpl::execute(DB::AddWeeksImpl, std::vector> const&, std::shared_ptr const&, unsigned short, unsigned long) @ 0x000000000aa92ff1 7. /build/src/Functions/FunctionDateOrDateTimeAddInterval.h:715: DB::FunctionDateOrDateTimeAddInterval::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000aa91c99 8. /build/src/Functions/IFunction.h:437: DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000a069f2a 9. /build/src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000012d9965a 10. /build/src/Functions/IFunction.cpp:351: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d93b02 11. /build/src/Functions/IFunction.cpp:177: DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d93698 12. /build/src/Functions/IFunction.cpp:343: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d93aad 13. /build/src/Functions/IFunction.cpp:420: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d95059 14. /build/src/Functions/IFunction.cpp:498: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d95c72 15. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3567: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000014034494 16. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3838: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000014019a9e 17. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3980: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000014018e31 18. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:4304: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000014042fa7 19. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5605: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000014013749 20. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000140127f9 21. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000014011fce 22. /build/src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000001406ce8a 23. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000014973b42 24. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000001497268d 25. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000014974d24 26. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001492924b 27. /build/src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88641 28. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 29. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 30. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 31. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 2025.07.28 11:53:27.144359 [ 17287 ] {} TCPHandler: Code: 407. DB::Exception: Numeric overflow: In scope SELECT addWeeks(toDateTime('2021-01-01 00:00:00', 'GMT'), 9223372036854775808). (DECIMAL_OVERFLOW), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000000a074fcb 4. /build/src/Functions/FunctionDateOrDateTimeAddInterval.h:486: void DB::Processor::vectorVector, DB::ColumnVector, DB::ColumnVector>(DB::ColumnVector const&, DB::ColumnVector&, DB::ColumnVector const&, DateLUTImpl const&, unsigned short, unsigned long) const @ 0x000000000aa9a9ad 5. /build/src/Functions/FunctionDateOrDateTimeAddInterval.h:466: void DB::Processor::vectorVector, DB::ColumnVector>(DB::ColumnVector const&, DB::ColumnVector&, DB::IColumn const&, DateLUTImpl const&, unsigned short, unsigned long) const @ 0x000000000aa99bbf 6. /build/src/Functions/FunctionDateOrDateTimeAddInterval.h:559: DB::DateTimeAddIntervalImpl::execute(DB::AddWeeksImpl, std::vector> const&, std::shared_ptr const&, unsigned short, unsigned long) @ 0x000000000aa92ff1 7. /build/src/Functions/FunctionDateOrDateTimeAddInterval.h:715: DB::FunctionDateOrDateTimeAddInterval::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000aa91c99 8. /build/src/Functions/IFunction.h:437: DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000a069f2a 9. /build/src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000012d9965a 10. /build/src/Functions/IFunction.cpp:351: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d93b02 11. /build/src/Functions/IFunction.cpp:177: DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d93698 12. /build/src/Functions/IFunction.cpp:343: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d93aad 13. /build/src/Functions/IFunction.cpp:420: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d95059 14. /build/src/Functions/IFunction.cpp:498: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d95c72 15. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3567: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000014034494 16. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3838: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000014019a9e 17. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3980: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000014018e31 18. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:4304: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000014042fa7 19. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5605: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000014013749 20. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000140127f9 21. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000014011fce 22. /build/src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000001406ce8a 23. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000014973b42 24. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000001497268d 25. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000014974d24 26. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001492924b 27. /build/src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88641 28. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 29. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 30. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 31. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 2025.07.28 11:53:27.197528 [ 5112 ] {026af5f2-a18d-4d19-9268-28b7d990777c} executeQuery: Code: 153. DB::Exception: Division by zero: In scope SELECT toDecimal32(0, 0) / toInt8(0). (ILLEGAL_DIVISION) (version 25.3.6.10636.altinitytest (altinity build)) (from [::1]:48688) (comment: 00700_decimal_arithm.sql) (query 49, line 77) (in query: SELECT toDecimal32(0, 0) / toInt8(0);), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000000a074fcb 4. /build/src/Functions/DivisionUtils.h:26: void DB::throwIfDivisionLeadsToFPE(int, int) @ 0x000000000b309e93 5. /build/src/Functions/FunctionBinaryArithmetic.h:0: _ZNK2DB24FunctionBinaryArithmeticINS_18DivideFloatingImplENS_10NameDivideELb1ELb1ELb0EE25executeNumericWithDecimalINS_15DataTypeDecimalINS_7DecimalIiEEEENS_14DataTypeNumberIDB8_EES8_S8_SB_NS_13ColumnDecimalIS7_EENS_12ColumnVectorISA_EEEEN3COWINS_7IColumnEE13immutable_ptrISH_EERKT2_RKT3_PKNS_11ColumnConstEST_PKT4_PKT5_mPKNS_8PODArrayIDuLm4096E9AllocatorILb0ELb0EELm63ELm64EEE @ 0x000000000b585f5c 6. /build/src/Functions/FunctionBinaryArithmetic.h:2270: COW::immutable_ptr> DB::FunctionBinaryArithmetic::executeNumeric>, DB::DataTypeNumber<_BitInt(8)>>(std::vector> const&, DB::DataTypeDecimal> const&, DB::DataTypeNumber<_BitInt(8)> const&, DB::PODArray, 63ul, 64ul> const*) const @ 0x000000000b585c84 7. /build/src/Functions/FunctionBinaryArithmetic.h:2508: 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&&) @ 0x000000000b581c91 8. /build/src/Functions/FunctionBinaryArithmetic.h:846: 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&&) @ 0x000000000b504403 9. /build/src/Functions/FunctionBinaryArithmetic.h:844: DB::FunctionBinaryArithmetic::executeImpl2(std::vector> const&, std::shared_ptr const&, unsigned long, DB::PODArray, 63ul, 64ul> const*) const @ 0x000000000b500305 10. /build/src/Functions/FunctionBinaryArithmetic.h:2410: DB::FunctionBinaryArithmetic::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000b4fe88c 11. /build/src/Functions/FunctionBinaryArithmetic.h:2645: DB::FunctionBinaryArithmeticWithConstants::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000b4fd634 12. /build/src/Functions/IFunction.h:437: DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000a069f2a 13. /build/src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000012d9965a 14. /build/src/Functions/IFunction.cpp:351: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d93b02 15. /build/src/Functions/IFunction.cpp:420: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d95059 16. /build/src/Functions/IFunction.cpp:498: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d95c72 17. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3567: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000014034494 18. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3838: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000014019a9e 19. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3980: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000014018e31 20. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:4304: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000014042fa7 21. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5605: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000014013749 22. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000140127f9 23. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000014011fce 24. /build/src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000001406ce8a 25. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000014973b42 26. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000001497268d 27. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000014974d24 28. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001492924b 29. /build/src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88641 30. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 31. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 2025.07.28 11:53:27.203008 [ 5112 ] {} TCPHandler: Code: 153. DB::Exception: Division by zero: In scope SELECT toDecimal32(0, 0) / toInt8(0). (ILLEGAL_DIVISION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000000a074fcb 4. /build/src/Functions/DivisionUtils.h:26: void DB::throwIfDivisionLeadsToFPE(int, int) @ 0x000000000b309e93 5. /build/src/Functions/FunctionBinaryArithmetic.h:0: _ZNK2DB24FunctionBinaryArithmeticINS_18DivideFloatingImplENS_10NameDivideELb1ELb1ELb0EE25executeNumericWithDecimalINS_15DataTypeDecimalINS_7DecimalIiEEEENS_14DataTypeNumberIDB8_EES8_S8_SB_NS_13ColumnDecimalIS7_EENS_12ColumnVectorISA_EEEEN3COWINS_7IColumnEE13immutable_ptrISH_EERKT2_RKT3_PKNS_11ColumnConstEST_PKT4_PKT5_mPKNS_8PODArrayIDuLm4096E9AllocatorILb0ELb0EELm63ELm64EEE @ 0x000000000b585f5c 6. /build/src/Functions/FunctionBinaryArithmetic.h:2270: COW::immutable_ptr> DB::FunctionBinaryArithmetic::executeNumeric>, DB::DataTypeNumber<_BitInt(8)>>(std::vector> const&, DB::DataTypeDecimal> const&, DB::DataTypeNumber<_BitInt(8)> const&, DB::PODArray, 63ul, 64ul> const*) const @ 0x000000000b585c84 7. /build/src/Functions/FunctionBinaryArithmetic.h:2508: 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&&) @ 0x000000000b581c91 8. /build/src/Functions/FunctionBinaryArithmetic.h:846: 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&&) @ 0x000000000b504403 9. /build/src/Functions/FunctionBinaryArithmetic.h:844: DB::FunctionBinaryArithmetic::executeImpl2(std::vector> const&, std::shared_ptr const&, unsigned long, DB::PODArray, 63ul, 64ul> const*) const @ 0x000000000b500305 10. /build/src/Functions/FunctionBinaryArithmetic.h:2410: DB::FunctionBinaryArithmetic::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000b4fe88c 11. /build/src/Functions/FunctionBinaryArithmetic.h:2645: DB::FunctionBinaryArithmeticWithConstants::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000b4fd634 12. /build/src/Functions/IFunction.h:437: DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000a069f2a 13. /build/src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000012d9965a 14. /build/src/Functions/IFunction.cpp:351: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d93b02 15. /build/src/Functions/IFunction.cpp:420: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d95059 16. /build/src/Functions/IFunction.cpp:498: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d95c72 17. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3567: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000014034494 18. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3838: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000014019a9e 19. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3980: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000014018e31 20. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:4304: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000014042fa7 21. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5605: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000014013749 22. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000140127f9 23. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000014011fce 24. /build/src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000001406ce8a 25. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000014973b42 26. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000001497268d 27. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000014974d24 28. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001492924b 29. /build/src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88641 30. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 31. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 2025.07.28 11:53:27.319302 [ 17287 ] {59e43640-4db4-4fb4-b1db-c882522fd9da} executeQuery: Code: 407. DB::Exception: Numeric overflow: In scope SELECT addDays(toDateTime('2021-01-01 00:00:00', 'GMT'), 9223372036854775808). (DECIMAL_OVERFLOW) (version 25.3.6.10636.altinitytest (altinity build)) (from [::1]:51276) (comment: 01662_date_ubsan.sql) (query 9, line 11) (in query: SELECT addDays(toDateTime('2021-01-01 00:00:00', 'GMT'), 9223372036854775808);), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000000a074fcb 4. /build/src/Functions/FunctionDateOrDateTimeAddInterval.h:486: void DB::Processor::vectorVector, DB::ColumnVector, DB::ColumnVector>(DB::ColumnVector const&, DB::ColumnVector&, DB::ColumnVector const&, DateLUTImpl const&, unsigned short, unsigned long) const @ 0x000000000a9ec7aa 5. /build/src/Functions/FunctionDateOrDateTimeAddInterval.h:466: void DB::Processor::vectorVector, DB::ColumnVector>(DB::ColumnVector const&, DB::ColumnVector&, DB::IColumn const&, DateLUTImpl const&, unsigned short, unsigned long) const @ 0x000000000a9eb9ff 6. /build/src/Functions/FunctionDateOrDateTimeAddInterval.h:559: DB::DateTimeAddIntervalImpl::execute(DB::AddDaysImpl, std::vector> const&, std::shared_ptr const&, unsigned short, unsigned long) @ 0x000000000a9e46d1 7. /build/src/Functions/FunctionDateOrDateTimeAddInterval.h:715: DB::FunctionDateOrDateTimeAddInterval::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000a9e3379 8. /build/src/Functions/IFunction.h:437: DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000a069f2a 9. /build/src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000012d9965a 10. /build/src/Functions/IFunction.cpp:351: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d93b02 11. /build/src/Functions/IFunction.cpp:177: DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d93698 12. /build/src/Functions/IFunction.cpp:343: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d93aad 13. /build/src/Functions/IFunction.cpp:420: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d95059 14. /build/src/Functions/IFunction.cpp:498: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d95c72 15. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3567: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000014034494 16. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3838: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000014019a9e 17. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3980: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000014018e31 18. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:4304: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000014042fa7 19. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5605: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000014013749 20. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000140127f9 21. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000014011fce 22. /build/src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000001406ce8a 23. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000014973b42 24. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000001497268d 25. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000014974d24 26. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001492924b 27. /build/src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88641 28. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 29. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 30. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 31. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 2025.07.28 11:53:27.324792 [ 17287 ] {} TCPHandler: Code: 407. DB::Exception: Numeric overflow: In scope SELECT addDays(toDateTime('2021-01-01 00:00:00', 'GMT'), 9223372036854775808). (DECIMAL_OVERFLOW), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000000a074fcb 4. /build/src/Functions/FunctionDateOrDateTimeAddInterval.h:486: void DB::Processor::vectorVector, DB::ColumnVector, DB::ColumnVector>(DB::ColumnVector const&, DB::ColumnVector&, DB::ColumnVector const&, DateLUTImpl const&, unsigned short, unsigned long) const @ 0x000000000a9ec7aa 5. /build/src/Functions/FunctionDateOrDateTimeAddInterval.h:466: void DB::Processor::vectorVector, DB::ColumnVector>(DB::ColumnVector const&, DB::ColumnVector&, DB::IColumn const&, DateLUTImpl const&, unsigned short, unsigned long) const @ 0x000000000a9eb9ff 6. /build/src/Functions/FunctionDateOrDateTimeAddInterval.h:559: DB::DateTimeAddIntervalImpl::execute(DB::AddDaysImpl, std::vector> const&, std::shared_ptr const&, unsigned short, unsigned long) @ 0x000000000a9e46d1 7. /build/src/Functions/FunctionDateOrDateTimeAddInterval.h:715: DB::FunctionDateOrDateTimeAddInterval::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000a9e3379 8. /build/src/Functions/IFunction.h:437: DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000a069f2a 9. /build/src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000012d9965a 10. /build/src/Functions/IFunction.cpp:351: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d93b02 11. /build/src/Functions/IFunction.cpp:177: DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d93698 12. /build/src/Functions/IFunction.cpp:343: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d93aad 13. /build/src/Functions/IFunction.cpp:420: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d95059 14. /build/src/Functions/IFunction.cpp:498: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d95c72 15. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3567: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000014034494 16. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3838: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000014019a9e 17. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3980: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000014018e31 18. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:4304: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000014042fa7 19. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5605: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000014013749 20. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000140127f9 21. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000014011fce 22. /build/src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000001406ce8a 23. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000014973b42 24. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000001497268d 25. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000014974d24 26. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001492924b 27. /build/src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88641 28. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 29. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 30. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 31. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 2025.07.28 11:53:27.464687 [ 5112 ] {a030fb2c-ce81-4b23-8f3a-ad49f1be9426} executeQuery: Code: 153. DB::Exception: Division by zero: In scope SELECT toDecimal64(0, 1) / toInt32(0). (ILLEGAL_DIVISION) (version 25.3.6.10636.altinitytest (altinity build)) (from [::1]:48688) (comment: 00700_decimal_arithm.sql) (query 50, line 78) (in query: SELECT toDecimal64(0, 1) / toInt32(0);), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000000a074fcb 4. /build/src/Functions/DivisionUtils.h:26: void DB::throwIfDivisionLeadsToFPE(long, long) @ 0x000000000b2fd11e 5. /build/src/Functions/FunctionBinaryArithmetic.h:0: COW::immutable_ptr DB::FunctionBinaryArithmetic::executeNumericWithDecimal>, DB::DataTypeNumber, DB::DataTypeDecimal>, DB::DataTypeDecimal>, DB::DataTypeNumber, DB::ColumnDecimal>, DB::ColumnVector>(DB::DataTypeDecimal> const&, DB::DataTypeNumber const&, DB::ColumnConst const*, DB::ColumnConst const*, DB::ColumnDecimal> const*, DB::ColumnVector const*, unsigned long, DB::PODArray, 63ul, 64ul> const*) const @ 0x000000000b592b5e 6. /build/src/Functions/FunctionBinaryArithmetic.h:2270: COW::immutable_ptr DB::FunctionBinaryArithmetic::executeNumeric>, DB::DataTypeNumber>(std::vector> const&, DB::DataTypeDecimal> const&, DB::DataTypeNumber const&, DB::PODArray, 63ul, 64ul> const*) const @ 0x000000000b592884 7. /build/src/Functions/FunctionBinaryArithmetic.h:2508: 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&&) @ 0x000000000b58d83f 8. /build/src/Functions/FunctionBinaryArithmetic.h:846: 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&&) @ 0x000000000b504483 9. /build/src/Functions/FunctionBinaryArithmetic.h:844: DB::FunctionBinaryArithmetic::executeImpl2(std::vector> const&, std::shared_ptr const&, unsigned long, DB::PODArray, 63ul, 64ul> const*) const @ 0x000000000b500305 10. /build/src/Functions/FunctionBinaryArithmetic.h:2410: DB::FunctionBinaryArithmetic::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000b4fe88c 11. /build/src/Functions/FunctionBinaryArithmetic.h:2645: DB::FunctionBinaryArithmeticWithConstants::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000b4fd634 12. /build/src/Functions/IFunction.h:437: DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000a069f2a 13. /build/src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000012d9965a 14. /build/src/Functions/IFunction.cpp:351: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d93b02 15. /build/src/Functions/IFunction.cpp:420: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d95059 16. /build/src/Functions/IFunction.cpp:498: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d95c72 17. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3567: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000014034494 18. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3838: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000014019a9e 19. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3980: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000014018e31 20. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:4304: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000014042fa7 21. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5605: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000014013749 22. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000140127f9 23. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000014011fce 24. /build/src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000001406ce8a 25. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000014973b42 26. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000001497268d 27. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000014974d24 28. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001492924b 29. /build/src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88641 30. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 31. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 2025.07.28 11:53:27.467946 [ 17287 ] {cc5f75c3-fb9b-4d1b-8a69-cab6b4ba8c65} executeQuery: Code: 407. DB::Exception: Numeric overflow: In scope SELECT addYears(toDateTime('2021-01-01 00:00:00', 'GMT'), 9223372036854775808). (DECIMAL_OVERFLOW) (version 25.3.6.10636.altinitytest (altinity build)) (from [::1]:51276) (comment: 01662_date_ubsan.sql) (query 10, line 12) (in query: SELECT addYears(toDateTime('2021-01-01 00:00:00', 'GMT'), 9223372036854775808);), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000000a074fcb 4. /build/src/Functions/FunctionDateOrDateTimeAddInterval.h:486: void DB::Processor::vectorVector, DB::ColumnVector, DB::ColumnVector>(DB::ColumnVector const&, DB::ColumnVector&, DB::ColumnVector const&, DateLUTImpl const&, unsigned short, unsigned long) const @ 0x000000000aab1698 5. /build/src/Functions/FunctionDateOrDateTimeAddInterval.h:466: void DB::Processor::vectorVector, DB::ColumnVector>(DB::ColumnVector const&, DB::ColumnVector&, DB::IColumn const&, DateLUTImpl const&, unsigned short, unsigned long) const @ 0x000000000aab067f 6. /build/src/Functions/FunctionDateOrDateTimeAddInterval.h:559: DB::DateTimeAddIntervalImpl::execute(DB::AddYearsImpl, std::vector> const&, std::shared_ptr const&, unsigned short, unsigned long) @ 0x000000000aaa66f1 7. /build/src/Functions/FunctionDateOrDateTimeAddInterval.h:715: DB::FunctionDateOrDateTimeAddInterval::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000aaa5399 8. /build/src/Functions/IFunction.h:437: DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000a069f2a 9. /build/src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000012d9965a 10. /build/src/Functions/IFunction.cpp:351: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d93b02 11. /build/src/Functions/IFunction.cpp:177: DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d93698 12. /build/src/Functions/IFunction.cpp:343: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d93aad 13. /build/src/Functions/IFunction.cpp:420: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d95059 14. /build/src/Functions/IFunction.cpp:498: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d95c72 15. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3567: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000014034494 16. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3838: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000014019a9e 17. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3980: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000014018e31 18. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:4304: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000014042fa7 19. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5605: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000014013749 20. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000140127f9 21. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000014011fce 22. /build/src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000001406ce8a 23. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000014973b42 24. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000001497268d 25. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000014974d24 26. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001492924b 27. /build/src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88641 28. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 29. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 30. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 31. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 2025.07.28 11:53:27.470091 [ 5112 ] {} TCPHandler: Code: 153. DB::Exception: Division by zero: In scope SELECT toDecimal64(0, 1) / toInt32(0). (ILLEGAL_DIVISION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000000a074fcb 4. /build/src/Functions/DivisionUtils.h:26: void DB::throwIfDivisionLeadsToFPE(long, long) @ 0x000000000b2fd11e 5. /build/src/Functions/FunctionBinaryArithmetic.h:0: COW::immutable_ptr DB::FunctionBinaryArithmetic::executeNumericWithDecimal>, DB::DataTypeNumber, DB::DataTypeDecimal>, DB::DataTypeDecimal>, DB::DataTypeNumber, DB::ColumnDecimal>, DB::ColumnVector>(DB::DataTypeDecimal> const&, DB::DataTypeNumber const&, DB::ColumnConst const*, DB::ColumnConst const*, DB::ColumnDecimal> const*, DB::ColumnVector const*, unsigned long, DB::PODArray, 63ul, 64ul> const*) const @ 0x000000000b592b5e 6. /build/src/Functions/FunctionBinaryArithmetic.h:2270: COW::immutable_ptr DB::FunctionBinaryArithmetic::executeNumeric>, DB::DataTypeNumber>(std::vector> const&, DB::DataTypeDecimal> const&, DB::DataTypeNumber const&, DB::PODArray, 63ul, 64ul> const*) const @ 0x000000000b592884 7. /build/src/Functions/FunctionBinaryArithmetic.h:2508: 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&&) @ 0x000000000b58d83f 8. /build/src/Functions/FunctionBinaryArithmetic.h:846: 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&&) @ 0x000000000b504483 9. /build/src/Functions/FunctionBinaryArithmetic.h:844: DB::FunctionBinaryArithmetic::executeImpl2(std::vector> const&, std::shared_ptr const&, unsigned long, DB::PODArray, 63ul, 64ul> const*) const @ 0x000000000b500305 10. /build/src/Functions/FunctionBinaryArithmetic.h:2410: DB::FunctionBinaryArithmetic::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000b4fe88c 11. /build/src/Functions/FunctionBinaryArithmetic.h:2645: DB::FunctionBinaryArithmeticWithConstants::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000b4fd634 12. /build/src/Functions/IFunction.h:437: DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000a069f2a 13. /build/src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000012d9965a 14. /build/src/Functions/IFunction.cpp:351: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d93b02 15. /build/src/Functions/IFunction.cpp:420: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d95059 16. /build/src/Functions/IFunction.cpp:498: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d95c72 17. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3567: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000014034494 18. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3838: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000014019a9e 19. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3980: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000014018e31 20. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:4304: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000014042fa7 21. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5605: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000014013749 22. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000140127f9 23. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000014011fce 24. /build/src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000001406ce8a 25. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000014973b42 26. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000001497268d 27. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000014974d24 28. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001492924b 29. /build/src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88641 30. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 31. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 2025.07.28 11:53:27.474238 [ 17287 ] {} TCPHandler: Code: 407. DB::Exception: Numeric overflow: In scope SELECT addYears(toDateTime('2021-01-01 00:00:00', 'GMT'), 9223372036854775808). (DECIMAL_OVERFLOW), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000000a074fcb 4. /build/src/Functions/FunctionDateOrDateTimeAddInterval.h:486: void DB::Processor::vectorVector, DB::ColumnVector, DB::ColumnVector>(DB::ColumnVector const&, DB::ColumnVector&, DB::ColumnVector const&, DateLUTImpl const&, unsigned short, unsigned long) const @ 0x000000000aab1698 5. /build/src/Functions/FunctionDateOrDateTimeAddInterval.h:466: void DB::Processor::vectorVector, DB::ColumnVector>(DB::ColumnVector const&, DB::ColumnVector&, DB::IColumn const&, DateLUTImpl const&, unsigned short, unsigned long) const @ 0x000000000aab067f 6. /build/src/Functions/FunctionDateOrDateTimeAddInterval.h:559: DB::DateTimeAddIntervalImpl::execute(DB::AddYearsImpl, std::vector> const&, std::shared_ptr const&, unsigned short, unsigned long) @ 0x000000000aaa66f1 7. /build/src/Functions/FunctionDateOrDateTimeAddInterval.h:715: DB::FunctionDateOrDateTimeAddInterval::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000aaa5399 8. /build/src/Functions/IFunction.h:437: DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000a069f2a 9. /build/src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000012d9965a 10. /build/src/Functions/IFunction.cpp:351: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d93b02 11. /build/src/Functions/IFunction.cpp:177: DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d93698 12. /build/src/Functions/IFunction.cpp:343: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d93aad 13. /build/src/Functions/IFunction.cpp:420: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d95059 14. /build/src/Functions/IFunction.cpp:498: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d95c72 15. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3567: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000014034494 16. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3838: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000014019a9e 17. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3980: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000014018e31 18. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:4304: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000014042fa7 19. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5605: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000014013749 20. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000140127f9 21. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000014011fce 22. /build/src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000001406ce8a 23. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000014973b42 24. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000001497268d 25. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000014974d24 26. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001492924b 27. /build/src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88641 28. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 29. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 30. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 31. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 2025.07.28 11:53:27.645931 [ 17287 ] {bfc5c962-f43c-4be0-9972-14dbd13bdf5b} executeQuery: Code: 407. DB::Exception: Numeric overflow: In scope SELECT addMinutes(toDateTime('2021-01-01 00:00:00', 'GMT'), inf). (DECIMAL_OVERFLOW) (version 25.3.6.10636.altinitytest (altinity build)) (from [::1]:51276) (comment: 01662_date_ubsan.sql) (query 11, line 13) (in query: -- tests with inf SELECT addMinutes(toDateTime('2021-01-01 00:00:00', 'GMT'), inf);), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000000a074fcb 4. /build/src/Functions/FunctionDateOrDateTimeAddInterval.h:486: long DB::Processor::checkOverflow(double) @ 0x000000000aa32be4 5. /build/src/Functions/FunctionDateOrDateTimeAddInterval.h:515: void DB::Processor::vectorVector, DB::ColumnVector, DB::ColumnVector>(DB::ColumnVector const&, DB::ColumnVector&, DB::ColumnVector const&, DateLUTImpl const&, unsigned short, unsigned long) const @ 0x000000000aa38a93 6. /build/src/Functions/FunctionDateOrDateTimeAddInterval.h:466: void DB::Processor::vectorVector, DB::ColumnVector>(DB::ColumnVector const&, DB::ColumnVector&, DB::IColumn const&, DateLUTImpl const&, unsigned short, unsigned long) const @ 0x000000000aa37542 7. /build/src/Functions/FunctionDateOrDateTimeAddInterval.h:559: DB::DateTimeAddIntervalImpl::execute(DB::AddMinutesImpl, std::vector> const&, std::shared_ptr const&, unsigned short, unsigned long) @ 0x000000000aa302d1 8. /build/src/Functions/FunctionDateOrDateTimeAddInterval.h:715: DB::FunctionDateOrDateTimeAddInterval::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000aa2ef59 9. /build/src/Functions/IFunction.h:437: DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000a069f2a 10. /build/src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000012d9965a 11. /build/src/Functions/IFunction.cpp:351: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d93b02 12. /build/src/Functions/IFunction.cpp:177: DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d93698 13. /build/src/Functions/IFunction.cpp:343: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d93aad 14. /build/src/Functions/IFunction.cpp:420: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d95059 15. /build/src/Functions/IFunction.cpp:498: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d95c72 16. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3567: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000014034494 17. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3838: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000014019a9e 18. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3980: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000014018e31 19. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:4304: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000014042fa7 20. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5605: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000014013749 21. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000140127f9 22. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000014011fce 23. /build/src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000001406ce8a 24. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000014973b42 25. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000001497268d 26. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000014974d24 27. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001492924b 28. /build/src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88641 29. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 30. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 31. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 2025.07.28 11:53:27.657103 [ 17287 ] {} TCPHandler: Code: 407. DB::Exception: Numeric overflow: In scope SELECT addMinutes(toDateTime('2021-01-01 00:00:00', 'GMT'), inf). (DECIMAL_OVERFLOW), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000000a074fcb 4. /build/src/Functions/FunctionDateOrDateTimeAddInterval.h:486: long DB::Processor::checkOverflow(double) @ 0x000000000aa32be4 5. /build/src/Functions/FunctionDateOrDateTimeAddInterval.h:515: void DB::Processor::vectorVector, DB::ColumnVector, DB::ColumnVector>(DB::ColumnVector const&, DB::ColumnVector&, DB::ColumnVector const&, DateLUTImpl const&, unsigned short, unsigned long) const @ 0x000000000aa38a93 6. /build/src/Functions/FunctionDateOrDateTimeAddInterval.h:466: void DB::Processor::vectorVector, DB::ColumnVector>(DB::ColumnVector const&, DB::ColumnVector&, DB::IColumn const&, DateLUTImpl const&, unsigned short, unsigned long) const @ 0x000000000aa37542 7. /build/src/Functions/FunctionDateOrDateTimeAddInterval.h:559: DB::DateTimeAddIntervalImpl::execute(DB::AddMinutesImpl, std::vector> const&, std::shared_ptr const&, unsigned short, unsigned long) @ 0x000000000aa302d1 8. /build/src/Functions/FunctionDateOrDateTimeAddInterval.h:715: DB::FunctionDateOrDateTimeAddInterval::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000aa2ef59 9. /build/src/Functions/IFunction.h:437: DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000a069f2a 10. /build/src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000012d9965a 11. /build/src/Functions/IFunction.cpp:351: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d93b02 12. /build/src/Functions/IFunction.cpp:177: DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d93698 13. /build/src/Functions/IFunction.cpp:343: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d93aad 14. /build/src/Functions/IFunction.cpp:420: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d95059 15. /build/src/Functions/IFunction.cpp:498: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d95c72 16. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3567: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000014034494 17. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3838: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000014019a9e 18. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3980: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000014018e31 19. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:4304: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000014042fa7 20. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5605: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000014013749 21. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000140127f9 22. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000014011fce 23. /build/src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000001406ce8a 24. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000014973b42 25. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000001497268d 26. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000014974d24 27. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001492924b 28. /build/src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88641 29. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 30. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 31. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 2025.07.28 11:53:27.743972 [ 17287 ] {81838509-755e-4a47-9f66-f85f0ae663b0} executeQuery: Code: 407. DB::Exception: Numeric overflow: In scope SELECT addHours(toDateTime('2021-01-01 00:00:00', 'GMT'), inf). (DECIMAL_OVERFLOW) (version 25.3.6.10636.altinitytest (altinity build)) (from [::1]:51276) (comment: 01662_date_ubsan.sql) (query 12, line 15) (in query: SELECT addHours(toDateTime('2021-01-01 00:00:00', 'GMT'), inf);), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000000a074fcb 4. /build/src/Functions/FunctionDateOrDateTimeAddInterval.h:486: long DB::Processor::checkOverflow(double) @ 0x000000000a9fb324 5. /build/src/Functions/FunctionDateOrDateTimeAddInterval.h:515: void DB::Processor::vectorVector, DB::ColumnVector, DB::ColumnVector>(DB::ColumnVector const&, DB::ColumnVector&, DB::ColumnVector const&, DateLUTImpl const&, unsigned short, unsigned long) const @ 0x000000000aa01287 6. /build/src/Functions/FunctionDateOrDateTimeAddInterval.h:466: void DB::Processor::vectorVector, DB::ColumnVector>(DB::ColumnVector const&, DB::ColumnVector&, DB::IColumn const&, DateLUTImpl const&, unsigned short, unsigned long) const @ 0x000000000a9ffd02 7. /build/src/Functions/FunctionDateOrDateTimeAddInterval.h:559: DB::DateTimeAddIntervalImpl::execute(DB::AddHoursImpl, std::vector> const&, std::shared_ptr const&, unsigned short, unsigned long) @ 0x000000000a9f89d1 8. /build/src/Functions/FunctionDateOrDateTimeAddInterval.h:715: DB::FunctionDateOrDateTimeAddInterval::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000a9f7659 9. /build/src/Functions/IFunction.h:437: DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000a069f2a 10. /build/src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000012d9965a 11. /build/src/Functions/IFunction.cpp:351: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d93b02 12. /build/src/Functions/IFunction.cpp:177: DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d93698 13. /build/src/Functions/IFunction.cpp:343: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d93aad 14. /build/src/Functions/IFunction.cpp:420: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d95059 15. /build/src/Functions/IFunction.cpp:498: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d95c72 16. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3567: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000014034494 17. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3838: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000014019a9e 18. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3980: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000014018e31 19. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:4304: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000014042fa7 20. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5605: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000014013749 21. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000140127f9 22. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000014011fce 23. /build/src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000001406ce8a 24. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000014973b42 25. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000001497268d 26. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000014974d24 27. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001492924b 28. /build/src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88641 29. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 30. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 31. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 2025.07.28 11:53:27.751053 [ 17287 ] {} TCPHandler: Code: 407. DB::Exception: Numeric overflow: In scope SELECT addHours(toDateTime('2021-01-01 00:00:00', 'GMT'), inf). (DECIMAL_OVERFLOW), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000000a074fcb 4. /build/src/Functions/FunctionDateOrDateTimeAddInterval.h:486: long DB::Processor::checkOverflow(double) @ 0x000000000a9fb324 5. /build/src/Functions/FunctionDateOrDateTimeAddInterval.h:515: void DB::Processor::vectorVector, DB::ColumnVector, DB::ColumnVector>(DB::ColumnVector const&, DB::ColumnVector&, DB::ColumnVector const&, DateLUTImpl const&, unsigned short, unsigned long) const @ 0x000000000aa01287 6. /build/src/Functions/FunctionDateOrDateTimeAddInterval.h:466: void DB::Processor::vectorVector, DB::ColumnVector>(DB::ColumnVector const&, DB::ColumnVector&, DB::IColumn const&, DateLUTImpl const&, unsigned short, unsigned long) const @ 0x000000000a9ffd02 7. /build/src/Functions/FunctionDateOrDateTimeAddInterval.h:559: DB::DateTimeAddIntervalImpl::execute(DB::AddHoursImpl, std::vector> const&, std::shared_ptr const&, unsigned short, unsigned long) @ 0x000000000a9f89d1 8. /build/src/Functions/FunctionDateOrDateTimeAddInterval.h:715: DB::FunctionDateOrDateTimeAddInterval::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000a9f7659 9. /build/src/Functions/IFunction.h:437: DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000a069f2a 10. /build/src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000012d9965a 11. /build/src/Functions/IFunction.cpp:351: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d93b02 12. /build/src/Functions/IFunction.cpp:177: DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d93698 13. /build/src/Functions/IFunction.cpp:343: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d93aad 14. /build/src/Functions/IFunction.cpp:420: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d95059 15. /build/src/Functions/IFunction.cpp:498: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d95c72 16. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3567: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000014034494 17. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3838: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000014019a9e 18. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3980: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000014018e31 19. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:4304: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000014042fa7 20. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5605: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000014013749 21. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000140127f9 22. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000014011fce 23. /build/src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000001406ce8a 24. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000014973b42 25. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000001497268d 26. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000014974d24 27. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001492924b 28. /build/src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88641 29. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 30. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 31. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 2025.07.28 11:53:27.852720 [ 5112 ] {74bd2d08-bcba-4122-946f-d193cb8eaca1} executeQuery: Code: 153. DB::Exception: Division by zero: In scope SELECT toDecimal128(0, 2) / toInt64(0). (ILLEGAL_DIVISION) (version 25.3.6.10636.altinitytest (altinity build)) (from [::1]:48688) (comment: 00700_decimal_arithm.sql) (query 51, line 79) (in query: SELECT toDecimal128(0, 2) / toInt64(0);), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000000a074fcb 4. /build/src/Functions/DivisionUtils.h:26: void DB::throwIfDivisionLeadsToFPE, wide::integer<128ul, int>>(wide::integer<128ul, int>, wide::integer<128ul, int>) @ 0x000000000b30d62f 5. /build/src/Functions/DivisionUtils.h:48: COW::immutable_ptr DB::FunctionBinaryArithmetic::executeNumericWithDecimal>>, DB::DataTypeNumber, DB::DataTypeDecimal>>, DB::DataTypeDecimal>>, DB::DataTypeNumber, DB::ColumnDecimal>>, DB::ColumnVector>(DB::DataTypeDecimal>> const&, DB::DataTypeNumber const&, DB::ColumnConst const*, DB::ColumnConst const*, DB::ColumnDecimal>> const*, DB::ColumnVector const*, unsigned long, DB::PODArray, 63ul, 64ul> const*) const @ 0x000000000b59fd53 6. /build/src/Functions/FunctionBinaryArithmetic.h:2270: COW::immutable_ptr DB::FunctionBinaryArithmetic::executeNumeric>>, DB::DataTypeNumber>(std::vector> const&, DB::DataTypeDecimal>> const&, DB::DataTypeNumber const&, DB::PODArray, 63ul, 64ul> const*) const @ 0x000000000b59f904 7. /build/src/Functions/FunctionBinaryArithmetic.h:2508: 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&&) @ 0x000000000b599251 8. /build/src/Functions/FunctionBinaryArithmetic.h:846: 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&&) @ 0x000000000b504503 9. /build/src/Functions/FunctionBinaryArithmetic.h:844: DB::FunctionBinaryArithmetic::executeImpl2(std::vector> const&, std::shared_ptr const&, unsigned long, DB::PODArray, 63ul, 64ul> const*) const @ 0x000000000b500305 10. /build/src/Functions/FunctionBinaryArithmetic.h:2410: DB::FunctionBinaryArithmetic::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000b4fe88c 11. /build/src/Functions/FunctionBinaryArithmetic.h:2645: DB::FunctionBinaryArithmeticWithConstants::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000b4fd634 12. /build/src/Functions/IFunction.h:437: DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000a069f2a 13. /build/src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000012d9965a 14. /build/src/Functions/IFunction.cpp:351: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d93b02 15. /build/src/Functions/IFunction.cpp:420: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d95059 16. /build/src/Functions/IFunction.cpp:498: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d95c72 17. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3567: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000014034494 18. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3838: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000014019a9e 19. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3980: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000014018e31 20. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:4304: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000014042fa7 21. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5605: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000014013749 22. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000140127f9 23. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000014011fce 24. /build/src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000001406ce8a 25. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000014973b42 26. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000001497268d 27. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000014974d24 28. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001492924b 29. /build/src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88641 30. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 31. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 2025.07.28 11:53:27.860069 [ 17287 ] {370458f9-e9f9-4ad5-9af3-ad866346520d} executeQuery: Code: 407. DB::Exception: Numeric overflow: In scope SELECT addWeeks(toDateTime('2021-01-01 00:00:00', 'GMT'), inf). (DECIMAL_OVERFLOW) (version 25.3.6.10636.altinitytest (altinity build)) (from [::1]:51276) (comment: 01662_date_ubsan.sql) (query 13, line 16) (in query: SELECT addWeeks(toDateTime('2021-01-01 00:00:00', 'GMT'), inf);), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000000a074fcb 4. /build/src/Functions/FunctionDateOrDateTimeAddInterval.h:486: long DB::Processor::checkOverflow(double) @ 0x000000000aa95864 5. /build/src/Functions/FunctionDateOrDateTimeAddInterval.h:515: void DB::Processor::vectorVector, DB::ColumnVector, DB::ColumnVector>(DB::ColumnVector const&, DB::ColumnVector&, DB::ColumnVector const&, DateLUTImpl const&, unsigned short, unsigned long) const @ 0x000000000aa9b978 6. /build/src/Functions/FunctionDateOrDateTimeAddInterval.h:466: void DB::Processor::vectorVector, DB::ColumnVector>(DB::ColumnVector const&, DB::ColumnVector&, DB::IColumn const&, DateLUTImpl const&, unsigned short, unsigned long) const @ 0x000000000aa99ca2 7. /build/src/Functions/FunctionDateOrDateTimeAddInterval.h:559: DB::DateTimeAddIntervalImpl::execute(DB::AddWeeksImpl, std::vector> const&, std::shared_ptr const&, unsigned short, unsigned long) @ 0x000000000aa92ff1 8. /build/src/Functions/FunctionDateOrDateTimeAddInterval.h:715: DB::FunctionDateOrDateTimeAddInterval::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000aa91c99 9. /build/src/Functions/IFunction.h:437: DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000a069f2a 10. /build/src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000012d9965a 11. /build/src/Functions/IFunction.cpp:351: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d93b02 12. /build/src/Functions/IFunction.cpp:177: DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d93698 13. /build/src/Functions/IFunction.cpp:343: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d93aad 14. /build/src/Functions/IFunction.cpp:420: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d95059 15. /build/src/Functions/IFunction.cpp:498: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d95c72 16. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3567: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000014034494 17. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3838: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000014019a9e 18. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3980: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000014018e31 19. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:4304: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000014042fa7 20. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5605: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000014013749 21. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000140127f9 22. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000014011fce 23. /build/src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000001406ce8a 24. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000014973b42 25. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000001497268d 26. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000014974d24 27. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001492924b 28. /build/src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88641 29. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 30. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 31. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 2025.07.28 11:53:27.873344 [ 5112 ] {} TCPHandler: Code: 153. DB::Exception: Division by zero: In scope SELECT toDecimal128(0, 2) / toInt64(0). (ILLEGAL_DIVISION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000000a074fcb 4. /build/src/Functions/DivisionUtils.h:26: void DB::throwIfDivisionLeadsToFPE, wide::integer<128ul, int>>(wide::integer<128ul, int>, wide::integer<128ul, int>) @ 0x000000000b30d62f 5. /build/src/Functions/DivisionUtils.h:48: COW::immutable_ptr DB::FunctionBinaryArithmetic::executeNumericWithDecimal>>, DB::DataTypeNumber, DB::DataTypeDecimal>>, DB::DataTypeDecimal>>, DB::DataTypeNumber, DB::ColumnDecimal>>, DB::ColumnVector>(DB::DataTypeDecimal>> const&, DB::DataTypeNumber const&, DB::ColumnConst const*, DB::ColumnConst const*, DB::ColumnDecimal>> const*, DB::ColumnVector const*, unsigned long, DB::PODArray, 63ul, 64ul> const*) const @ 0x000000000b59fd53 6. /build/src/Functions/FunctionBinaryArithmetic.h:2270: COW::immutable_ptr DB::FunctionBinaryArithmetic::executeNumeric>>, DB::DataTypeNumber>(std::vector> const&, DB::DataTypeDecimal>> const&, DB::DataTypeNumber const&, DB::PODArray, 63ul, 64ul> const*) const @ 0x000000000b59f904 7. /build/src/Functions/FunctionBinaryArithmetic.h:2508: 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&&) @ 0x000000000b599251 8. /build/src/Functions/FunctionBinaryArithmetic.h:846: 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&&) @ 0x000000000b504503 9. /build/src/Functions/FunctionBinaryArithmetic.h:844: DB::FunctionBinaryArithmetic::executeImpl2(std::vector> const&, std::shared_ptr const&, unsigned long, DB::PODArray, 63ul, 64ul> const*) const @ 0x000000000b500305 10. /build/src/Functions/FunctionBinaryArithmetic.h:2410: DB::FunctionBinaryArithmetic::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000b4fe88c 11. /build/src/Functions/FunctionBinaryArithmetic.h:2645: DB::FunctionBinaryArithmeticWithConstants::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000b4fd634 12. /build/src/Functions/IFunction.h:437: DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000a069f2a 13. /build/src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000012d9965a 14. /build/src/Functions/IFunction.cpp:351: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d93b02 15. /build/src/Functions/IFunction.cpp:420: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d95059 16. /build/src/Functions/IFunction.cpp:498: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d95c72 17. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3567: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000014034494 18. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3838: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000014019a9e 19. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3980: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000014018e31 20. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:4304: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000014042fa7 21. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5605: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000014013749 22. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000140127f9 23. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000014011fce 24. /build/src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000001406ce8a 25. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000014973b42 26. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000001497268d 27. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000014974d24 28. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001492924b 29. /build/src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88641 30. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 31. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 2025.07.28 11:53:27.879564 [ 17287 ] {} TCPHandler: Code: 407. DB::Exception: Numeric overflow: In scope SELECT addWeeks(toDateTime('2021-01-01 00:00:00', 'GMT'), inf). (DECIMAL_OVERFLOW), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000000a074fcb 4. /build/src/Functions/FunctionDateOrDateTimeAddInterval.h:486: long DB::Processor::checkOverflow(double) @ 0x000000000aa95864 5. /build/src/Functions/FunctionDateOrDateTimeAddInterval.h:515: void DB::Processor::vectorVector, DB::ColumnVector, DB::ColumnVector>(DB::ColumnVector const&, DB::ColumnVector&, DB::ColumnVector const&, DateLUTImpl const&, unsigned short, unsigned long) const @ 0x000000000aa9b978 6. /build/src/Functions/FunctionDateOrDateTimeAddInterval.h:466: void DB::Processor::vectorVector, DB::ColumnVector>(DB::ColumnVector const&, DB::ColumnVector&, DB::IColumn const&, DateLUTImpl const&, unsigned short, unsigned long) const @ 0x000000000aa99ca2 7. /build/src/Functions/FunctionDateOrDateTimeAddInterval.h:559: DB::DateTimeAddIntervalImpl::execute(DB::AddWeeksImpl, std::vector> const&, std::shared_ptr const&, unsigned short, unsigned long) @ 0x000000000aa92ff1 8. /build/src/Functions/FunctionDateOrDateTimeAddInterval.h:715: DB::FunctionDateOrDateTimeAddInterval::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000aa91c99 9. /build/src/Functions/IFunction.h:437: DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000a069f2a 10. /build/src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000012d9965a 11. /build/src/Functions/IFunction.cpp:351: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d93b02 12. /build/src/Functions/IFunction.cpp:177: DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d93698 13. /build/src/Functions/IFunction.cpp:343: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d93aad 14. /build/src/Functions/IFunction.cpp:420: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d95059 15. /build/src/Functions/IFunction.cpp:498: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d95c72 16. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3567: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000014034494 17. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3838: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000014019a9e 18. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3980: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000014018e31 19. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:4304: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000014042fa7 20. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5605: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000014013749 21. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000140127f9 22. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000014011fce 23. /build/src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000001406ce8a 24. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000014973b42 25. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000001497268d 26. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000014974d24 27. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001492924b 28. /build/src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88641 29. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 30. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 31. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 2025.07.28 11:53:28.073550 [ 3974 ] {} test_13.rmt2 (7f9b740d-015c-470e-8cc6-8ba33be0dc63): auto DB::StorageReplicatedMergeTree::processQueueEntry(ReplicatedMergeTreeQueue::SelectedEntryPtr)::(anonymous class)::operator()(LogEntryPtr &) const: Code: 86. DB::HTTPException: Received error from remote server http://146b4357c08d:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Ftest%2F01165%2Ftest_13%2Frmt%2Freplicas%2F1&part=20250728_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.6.10636.altinitytest (altinity build)) '. (RECEIVED_ERROR_FROM_REMOTE_IO_SERVER), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.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 const&, int&&, String const&, unsigned long&&, String const&) @ 0x000000000feda8d9 4. /build/src/IO/HTTPCommon.cpp:104: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x000000000feda6e2 5. /build/src/IO/HTTPCommon.cpp:93: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x000000000feda537 6. /build/src/IO/ReadWriteBufferFromHTTP.cpp:277: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x000000001184a4c4 7. /build/src/IO/ReadWriteBufferFromHTTP.cpp:285: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x000000001184a615 8. /build/src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x000000001184ae59 9. /build/src/IO/ReadWriteBufferFromHTTP.cpp:472: void std::__function::__policy_invoker::__call_impl[abi:se190107]>(std::__function::__policy_storage const*) @ 0x000000001184cedd 10. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001184858b 11. /build/src/IO/ReadWriteBufferFromHTTP.cpp:465: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x000000001184bf0b 12. /build/src/IO/ReadBuffer.h:60: DB::ReadBuffer::next() @ 0x000000000a148c7b 13. /build/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) @ 0x0000000011849fb2 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]>&)>&, 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&) @ 0x0000000011841980 15. /build/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) @ 0x000000001621208e 16. /build/src/Storages/StorageReplicatedMergeTree.cpp:5228: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl[abi:se190107] const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000015f9a5fe 17. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000015ed8bfd 18. /build/src/Storages/StorageReplicatedMergeTree.cpp:2514: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x0000000015ec9aab 19. /build/src/Storages/StorageReplicatedMergeTree.cpp:2349: DB::StorageReplicatedMergeTree::executeLogEntry(DB::ReplicatedMergeTreeLogEntry&) @ 0x0000000015eba91b 20. /build/src/Storages/StorageReplicatedMergeTree.cpp:3876: bool std::__function::__policy_invoker&)>::__call_impl[abi:se190107])::$_1, bool (std::shared_ptr&)>>(std::__function::__policy_storage const*, std::shared_ptr&) @ 0x0000000015f9837e 21. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000165d6fc3 22. /build/src/Storages/StorageReplicatedMergeTree.cpp:3872: DB::StorageReplicatedMergeTree::processQueueEntry(std::shared_ptr) @ 0x0000000015efc18a 23. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001624c1b2 24. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000162f9c70 25. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x00000000162fa55a 26. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc6653 27. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000000fccc4c3 28. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc3d92 29. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fcca080 30. ? @ 0x00007fbc6213eac3 31. ? @ 0x00007fbc621d0850 (version 25.3.6.10636.altinitytest (altinity build)) 2025.07.28 11:53:28.075061 [ 7625 ] {deedc6db-c92f-400c-9f9d-7dfd5c1dd269} executeQuery: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=0, jobs=0). (CANNOT_SCHEDULE_TASK) (version 25.3.6.10636.altinitytest (altinity build)) (from [::1]:51306) (comment: 00675_shard_remote_with_table_function.sql) (query 7, line 9) (in query: SELECT COUNT(*) FROM remote('127.0.0.1', currentDatabase(), remote_test);), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000fccaeeb 4. /build/src/Common/ThreadPool.cpp:275: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000fccc813 5. /build/src/Common/ThreadPool.cpp:323: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fcc7bbc 6. /build/src/Common/ThreadPool.cpp:494: ThreadPoolImpl>::scheduleOrThrowOnError(std::function, Priority) @ 0x000000000fcc7a0e 7. /build/src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::spawnThreadsImpl() @ 0x00000000169b2c0c 8. /build/src/Processors/Executors/PipelineExecutor.cpp:394: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x00000000169b0ba7 9. /build/src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x00000000169b03f4 10. /build/src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:se190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169bfeab 11. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc3d92 12. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fcca080 13. ? @ 0x00007fbc6213eac3 14. ? @ 0x00007fbc621d0850 2025.07.28 11:53:28.102205 [ 7625 ] {} 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. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000fccaeeb 4. /build/src/Common/ThreadPool.cpp:275: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000fccc813 5. /build/src/Common/ThreadPool.cpp:323: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fcc7bbc 6. /build/src/Common/ThreadPool.cpp:494: ThreadPoolImpl>::scheduleOrThrowOnError(std::function, Priority) @ 0x000000000fcc7a0e 7. /build/src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::spawnThreadsImpl() @ 0x00000000169b2c0c 8. /build/src/Processors/Executors/PipelineExecutor.cpp:394: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x00000000169b0ba7 9. /build/src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x00000000169b03f4 10. /build/src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:se190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169bfeab 11. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc3d92 12. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fcca080 13. ? @ 0x00007fbc6213eac3 14. ? @ 0x00007fbc621d0850 Job's origin stack trace: 0. /build/src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000000fc33b84 1. /build/src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000000fcc2ea7 2. /build/src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fcc535c 3. /build/src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000000fcc584d 4. /build/src/Common/ThreadPool.h:279: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x00000000169bf193 5. /build/src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x00000000169bf518 6. /build/src/Server/TCPHandler.cpp:1237: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x00000000168f1525 7. /build/src/Server/TCPHandler.cpp:678: DB::TCPHandler::runImpl() @ 0x00000000168e68e5 8. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 9. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 10. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 11. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 12. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 13. ? @ 0x00007fbc6213eac3 14. ? @ 0x00007fbc621d0850 2025.07.28 11:53:28.165297 [ 17287 ] {3d177af0-22a9-4079-8bfd-605cacdb1484} executeQuery: Code: 407. DB::Exception: Numeric overflow: In scope SELECT addDays(toDateTime('2021-01-01 00:00:00', 'GMT'), inf). (DECIMAL_OVERFLOW) (version 25.3.6.10636.altinitytest (altinity build)) (from [::1]:51276) (comment: 01662_date_ubsan.sql) (query 14, line 17) (in query: SELECT addDays(toDateTime('2021-01-01 00:00:00', 'GMT'), inf);), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000000a074fcb 4. /build/src/Functions/FunctionDateOrDateTimeAddInterval.h:486: long DB::Processor::checkOverflow(double) @ 0x000000000a9e7344 5. /build/src/Functions/FunctionDateOrDateTimeAddInterval.h:515: void DB::Processor::vectorVector, DB::ColumnVector, DB::ColumnVector>(DB::ColumnVector const&, DB::ColumnVector&, DB::ColumnVector const&, DateLUTImpl const&, unsigned short, unsigned long) const @ 0x000000000a9ed718 6. /build/src/Functions/FunctionDateOrDateTimeAddInterval.h:466: void DB::Processor::vectorVector, DB::ColumnVector>(DB::ColumnVector const&, DB::ColumnVector&, DB::IColumn const&, DateLUTImpl const&, unsigned short, unsigned long) const @ 0x000000000a9ebae2 7. /build/src/Functions/FunctionDateOrDateTimeAddInterval.h:559: DB::DateTimeAddIntervalImpl::execute(DB::AddDaysImpl, std::vector> const&, std::shared_ptr const&, unsigned short, unsigned long) @ 0x000000000a9e46d1 8. /build/src/Functions/FunctionDateOrDateTimeAddInterval.h:715: DB::FunctionDateOrDateTimeAddInterval::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000a9e3379 9. /build/src/Functions/IFunction.h:437: DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000a069f2a 10. /build/src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000012d9965a 11. /build/src/Functions/IFunction.cpp:351: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d93b02 12. /build/src/Functions/IFunction.cpp:177: DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d93698 13. /build/src/Functions/IFunction.cpp:343: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d93aad 14. /build/src/Functions/IFunction.cpp:420: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d95059 15. /build/src/Functions/IFunction.cpp:498: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d95c72 16. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3567: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000014034494 17. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3838: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000014019a9e 18. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3980: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000014018e31 19. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:4304: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000014042fa7 20. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5605: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000014013749 21. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000140127f9 22. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000014011fce 23. /build/src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000001406ce8a 24. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000014973b42 25. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000001497268d 26. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000014974d24 27. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001492924b 28. /build/src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88641 29. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 30. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 31. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 2025.07.28 11:53:28.170312 [ 17287 ] {} TCPHandler: Code: 407. DB::Exception: Numeric overflow: In scope SELECT addDays(toDateTime('2021-01-01 00:00:00', 'GMT'), inf). (DECIMAL_OVERFLOW), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000000a074fcb 4. /build/src/Functions/FunctionDateOrDateTimeAddInterval.h:486: long DB::Processor::checkOverflow(double) @ 0x000000000a9e7344 5. /build/src/Functions/FunctionDateOrDateTimeAddInterval.h:515: void DB::Processor::vectorVector, DB::ColumnVector, DB::ColumnVector>(DB::ColumnVector const&, DB::ColumnVector&, DB::ColumnVector const&, DateLUTImpl const&, unsigned short, unsigned long) const @ 0x000000000a9ed718 6. /build/src/Functions/FunctionDateOrDateTimeAddInterval.h:466: void DB::Processor::vectorVector, DB::ColumnVector>(DB::ColumnVector const&, DB::ColumnVector&, DB::IColumn const&, DateLUTImpl const&, unsigned short, unsigned long) const @ 0x000000000a9ebae2 7. /build/src/Functions/FunctionDateOrDateTimeAddInterval.h:559: DB::DateTimeAddIntervalImpl::execute(DB::AddDaysImpl, std::vector> const&, std::shared_ptr const&, unsigned short, unsigned long) @ 0x000000000a9e46d1 8. /build/src/Functions/FunctionDateOrDateTimeAddInterval.h:715: DB::FunctionDateOrDateTimeAddInterval::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000a9e3379 9. /build/src/Functions/IFunction.h:437: DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000a069f2a 10. /build/src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000012d9965a 11. /build/src/Functions/IFunction.cpp:351: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d93b02 12. /build/src/Functions/IFunction.cpp:177: DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d93698 13. /build/src/Functions/IFunction.cpp:343: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d93aad 14. /build/src/Functions/IFunction.cpp:420: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d95059 15. /build/src/Functions/IFunction.cpp:498: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d95c72 16. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3567: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000014034494 17. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3838: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000014019a9e 18. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3980: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000014018e31 19. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:4304: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000014042fa7 20. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5605: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000014013749 21. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000140127f9 22. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000014011fce 23. /build/src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000001406ce8a 24. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000014973b42 25. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000001497268d 26. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000014974d24 27. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001492924b 28. /build/src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88641 29. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 30. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 31. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 2025.07.28 11:53:28.341061 [ 17287 ] {cf559869-24c4-4501-859f-7ea256a69397} executeQuery: Code: 407. DB::Exception: Numeric overflow: In scope SELECT addYears(toDateTime('2021-01-01 00:00:00', 'GMT'), inf). (DECIMAL_OVERFLOW) (version 25.3.6.10636.altinitytest (altinity build)) (from [::1]:51276) (comment: 01662_date_ubsan.sql) (query 15, line 18) (in query: SELECT addYears(toDateTime('2021-01-01 00:00:00', 'GMT'), inf);), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000000a074fcb 4. /build/src/Functions/FunctionDateOrDateTimeAddInterval.h:486: long DB::Processor::checkOverflow(double) @ 0x000000000aaa9be4 5. /build/src/Functions/FunctionDateOrDateTimeAddInterval.h:515: void DB::Processor::vectorVector, DB::ColumnVector, DB::ColumnVector>(DB::ColumnVector const&, DB::ColumnVector&, DB::ColumnVector const&, DateLUTImpl const&, unsigned short, unsigned long) const @ 0x000000000aab2778 6. /build/src/Functions/FunctionDateOrDateTimeAddInterval.h:466: void DB::Processor::vectorVector, DB::ColumnVector>(DB::ColumnVector const&, DB::ColumnVector&, DB::IColumn const&, DateLUTImpl const&, unsigned short, unsigned long) const @ 0x000000000aab0762 7. /build/src/Functions/FunctionDateOrDateTimeAddInterval.h:559: DB::DateTimeAddIntervalImpl::execute(DB::AddYearsImpl, std::vector> const&, std::shared_ptr const&, unsigned short, unsigned long) @ 0x000000000aaa66f1 8. /build/src/Functions/FunctionDateOrDateTimeAddInterval.h:715: DB::FunctionDateOrDateTimeAddInterval::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000aaa5399 9. /build/src/Functions/IFunction.h:437: DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000a069f2a 10. /build/src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000012d9965a 11. /build/src/Functions/IFunction.cpp:351: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d93b02 12. /build/src/Functions/IFunction.cpp:177: DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d93698 13. /build/src/Functions/IFunction.cpp:343: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d93aad 14. /build/src/Functions/IFunction.cpp:420: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d95059 15. /build/src/Functions/IFunction.cpp:498: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d95c72 16. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3567: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000014034494 17. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3838: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000014019a9e 18. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3980: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000014018e31 19. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:4304: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000014042fa7 20. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5605: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000014013749 21. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000140127f9 22. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000014011fce 23. /build/src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000001406ce8a 24. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000014973b42 25. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000001497268d 26. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000014974d24 27. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001492924b 28. /build/src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88641 29. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 30. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 31. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 2025.07.28 11:53:28.352449 [ 17287 ] {} TCPHandler: Code: 407. DB::Exception: Numeric overflow: In scope SELECT addYears(toDateTime('2021-01-01 00:00:00', 'GMT'), inf). (DECIMAL_OVERFLOW), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000000a074fcb 4. /build/src/Functions/FunctionDateOrDateTimeAddInterval.h:486: long DB::Processor::checkOverflow(double) @ 0x000000000aaa9be4 5. /build/src/Functions/FunctionDateOrDateTimeAddInterval.h:515: void DB::Processor::vectorVector, DB::ColumnVector, DB::ColumnVector>(DB::ColumnVector const&, DB::ColumnVector&, DB::ColumnVector const&, DateLUTImpl const&, unsigned short, unsigned long) const @ 0x000000000aab2778 6. /build/src/Functions/FunctionDateOrDateTimeAddInterval.h:466: void DB::Processor::vectorVector, DB::ColumnVector>(DB::ColumnVector const&, DB::ColumnVector&, DB::IColumn const&, DateLUTImpl const&, unsigned short, unsigned long) const @ 0x000000000aab0762 7. /build/src/Functions/FunctionDateOrDateTimeAddInterval.h:559: DB::DateTimeAddIntervalImpl::execute(DB::AddYearsImpl, std::vector> const&, std::shared_ptr const&, unsigned short, unsigned long) @ 0x000000000aaa66f1 8. /build/src/Functions/FunctionDateOrDateTimeAddInterval.h:715: DB::FunctionDateOrDateTimeAddInterval::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000aaa5399 9. /build/src/Functions/IFunction.h:437: DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000a069f2a 10. /build/src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000012d9965a 11. /build/src/Functions/IFunction.cpp:351: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d93b02 12. /build/src/Functions/IFunction.cpp:177: DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d93698 13. /build/src/Functions/IFunction.cpp:343: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d93aad 14. /build/src/Functions/IFunction.cpp:420: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d95059 15. /build/src/Functions/IFunction.cpp:498: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d95c72 16. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3567: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000014034494 17. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3838: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000014019a9e 18. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3980: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000014018e31 19. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:4304: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000014042fa7 20. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5605: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000014013749 21. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000140127f9 22. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000014011fce 23. /build/src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000001406ce8a 24. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000014973b42 25. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000001497268d 26. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000014974d24 27. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001492924b 28. /build/src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88641 29. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 30. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 31. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 2025.07.28 11:53:28.513247 [ 3969 ] {} test_13.rmt2 (7f9b740d-015c-470e-8cc6-8ba33be0dc63): auto DB::StorageReplicatedMergeTree::processQueueEntry(ReplicatedMergeTreeQueue::SelectedEntryPtr)::(anonymous class)::operator()(LogEntryPtr &) const: Code: 86. DB::HTTPException: Received error from remote server http://146b4357c08d:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Ftest%2F01165%2Ftest_13%2Frmt%2Freplicas%2F1&part=20250728_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.6.10636.altinitytest (altinity build)) '. (RECEIVED_ERROR_FROM_REMOTE_IO_SERVER), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.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 const&, int&&, String const&, unsigned long&&, String const&) @ 0x000000000feda8d9 4. /build/src/IO/HTTPCommon.cpp:104: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x000000000feda6e2 5. /build/src/IO/HTTPCommon.cpp:93: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x000000000feda537 6. /build/src/IO/ReadWriteBufferFromHTTP.cpp:277: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x000000001184a4c4 7. /build/src/IO/ReadWriteBufferFromHTTP.cpp:285: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x000000001184a615 8. /build/src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x000000001184ae59 9. /build/src/IO/ReadWriteBufferFromHTTP.cpp:472: void std::__function::__policy_invoker::__call_impl[abi:se190107]>(std::__function::__policy_storage const*) @ 0x000000001184cedd 10. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001184858b 11. /build/src/IO/ReadWriteBufferFromHTTP.cpp:465: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x000000001184bf0b 12. /build/src/IO/ReadBuffer.h:60: DB::ReadBuffer::next() @ 0x000000000a148c7b 13. /build/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) @ 0x0000000011849fb2 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]>&)>&, 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&) @ 0x0000000011841980 15. /build/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) @ 0x000000001621208e 16. /build/src/Storages/StorageReplicatedMergeTree.cpp:5228: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl[abi:se190107] const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000015f9a5fe 17. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000015ed8bfd 18. /build/src/Storages/StorageReplicatedMergeTree.cpp:2514: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x0000000015ec9aab 19. /build/src/Storages/StorageReplicatedMergeTree.cpp:2349: DB::StorageReplicatedMergeTree::executeLogEntry(DB::ReplicatedMergeTreeLogEntry&) @ 0x0000000015eba91b 20. /build/src/Storages/StorageReplicatedMergeTree.cpp:3876: bool std::__function::__policy_invoker&)>::__call_impl[abi:se190107])::$_1, bool (std::shared_ptr&)>>(std::__function::__policy_storage const*, std::shared_ptr&) @ 0x0000000015f9837e 21. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000165d6fc3 22. /build/src/Storages/StorageReplicatedMergeTree.cpp:3872: DB::StorageReplicatedMergeTree::processQueueEntry(std::shared_ptr) @ 0x0000000015efc18a 23. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001624c1b2 24. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000162f9c70 25. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x00000000162fa55a 26. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc6653 27. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000000fccc4c3 28. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc3d92 29. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fcca080 30. ? @ 0x00007fbc6213eac3 31. ? @ 0x00007fbc621d0850 (version 25.3.6.10636.altinitytest (altinity build)) 2025.07.28 11:53:28.604008 [ 5327 ] {dc5db6c3-d92a-4537-a31d-e0cb0887f739} executeQuery: Code: 160. DB::Exception: The maximum sleep time is 3000000 microseconds. Requested: 4295967296 microseconds: while executing 'FUNCTION sleep(4295.967296_Float64 :: 1) -> sleep(4295.967296_Float64) UInt8 : 2'. (TOO_SLOW) (version 25.3.6.10636.altinitytest (altinity build)) (from [::1]:51354) (comment: 00833_sleep_overflow.sql) (query 1, line 1) (in query: SELECT sleep(4295.967296);), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, unsigned long const&, unsigned long&) @ 0x000000000a07992b 4. /build/src/Functions/sleep.cpp:131: DB::(anonymous namespace)::FunctionSleep<(DB::(anonymous namespace)::FunctionSleepVariant)0>::execute(std::vector> const&, std::shared_ptr const&, bool) const @ 0x000000000e6d1704 5. /build/src/Functions/sleep.cpp:106: DB::(anonymous namespace)::FunctionSleep<(DB::(anonymous namespace)::FunctionSleepVariant)0>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000e6d102c 6. /build/src/Functions/IFunctionAdaptors.cpp:10: DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000012d995fa 7. /build/src/Functions/IFunction.cpp:353: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d93b52 8. /build/src/Functions/IFunction.cpp:420: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d95059 9. /build/src/Functions/IFunction.cpp:498: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d95c72 10. /build/src/Interpreters/ExpressionActions.cpp:636: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x00000000145176f3 11. /build/src/Processors/Transforms/ExpressionTransform.cpp:25: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x0000000016c0b34c 12. /build/src/Processors/ISimpleTransform.h:33: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000011a9a453 13. /build/src/Processors/ISimpleTransform.cpp:89: DB::ISimpleTransform::work() @ 0x000000001699fca0 14. /build/src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x00000000169bd00f 15. /build/src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x00000000169b2105 16. /build/src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeSingleThread(unsigned long) @ 0x00000000169b23be 17. /build/src/Processors/Executors/PipelineExecutor.cpp:454: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x00000000169b0be7 18. /build/src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x00000000169b03f4 19. /build/src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:se190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169bfeab 20. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc3d92 21. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fcca080 22. ? @ 0x00007fbc6213eac3 23. ? @ 0x00007fbc621d0850 2025.07.28 11:53:28.608652 [ 5327 ] {} TCPHandler: Code: 160. DB::Exception: The maximum sleep time is 3000000 microseconds. Requested: 4295967296 microseconds: while executing 'FUNCTION sleep(4295.967296_Float64 :: 1) -> sleep(4295.967296_Float64) UInt8 : 2'. (TOO_SLOW), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, unsigned long const&, unsigned long&) @ 0x000000000a07992b 4. /build/src/Functions/sleep.cpp:131: DB::(anonymous namespace)::FunctionSleep<(DB::(anonymous namespace)::FunctionSleepVariant)0>::execute(std::vector> const&, std::shared_ptr const&, bool) const @ 0x000000000e6d1704 5. /build/src/Functions/sleep.cpp:106: DB::(anonymous namespace)::FunctionSleep<(DB::(anonymous namespace)::FunctionSleepVariant)0>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000e6d102c 6. /build/src/Functions/IFunctionAdaptors.cpp:10: DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000012d995fa 7. /build/src/Functions/IFunction.cpp:353: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d93b52 8. /build/src/Functions/IFunction.cpp:420: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d95059 9. /build/src/Functions/IFunction.cpp:498: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d95c72 10. /build/src/Interpreters/ExpressionActions.cpp:636: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x00000000145176f3 11. /build/src/Processors/Transforms/ExpressionTransform.cpp:25: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x0000000016c0b34c 12. /build/src/Processors/ISimpleTransform.h:33: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000011a9a453 13. /build/src/Processors/ISimpleTransform.cpp:89: DB::ISimpleTransform::work() @ 0x000000001699fca0 14. /build/src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x00000000169bd00f 15. /build/src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x00000000169b2105 16. /build/src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeSingleThread(unsigned long) @ 0x00000000169b23be 17. /build/src/Processors/Executors/PipelineExecutor.cpp:454: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x00000000169b0be7 18. /build/src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x00000000169b03f4 19. /build/src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:se190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169bfeab 20. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc3d92 21. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fcca080 22. ? @ 0x00007fbc6213eac3 23. ? @ 0x00007fbc621d0850 Job's origin stack trace: 0. /build/src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000000fc33b84 1. /build/src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000000fcc2ea7 2. /build/src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fcc535c 3. /build/src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000000fcc584d 4. /build/src/Common/ThreadPool.h:279: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x00000000169bf193 5. /build/src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x00000000169bf518 6. /build/src/Server/TCPHandler.cpp:1237: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x00000000168f1525 7. /build/src/Server/TCPHandler.cpp:678: DB::TCPHandler::runImpl() @ 0x00000000168e68e5 8. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 9. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 10. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 11. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 12. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 13. ? @ 0x00007fbc6213eac3 14. ? @ 0x00007fbc621d0850 2025.07.28 11:53:28.669684 [ 5112 ] {235c07d3-fb18-4f85-96b8-55e199d6f2b8} executeQuery: Code: 407. DB::Exception: Overflow during decimal division: In scope SELECT toDecimal128(1, 38) / toDecimal128(1, 1) SETTINGS decimal_check_overflow = 1. (DECIMAL_OVERFLOW) (version 25.3.6.10636.altinitytest (altinity build)) (from [::1]:48688) (comment: 00700_decimal_arithm.sql) (query 56, line 87) (in query: SELECT toDecimal128(1, 38) / toDecimal128(1, 1) SETTINGS decimal_check_overflow=1;), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000000a074fcb 4. /build/src/Functions/FunctionBinaryArithmetic.h:1888: auto DB::FunctionBinaryArithmetic::getReturnTypeImplStatic(std::vector, std::allocator>> const&, std::shared_ptr)::'lambda'(auto const&, auto const&)::operator()>>, DB::DataTypeDecimal>>>(auto const&, auto const&) const @ 0x000000000b5e69d9 5. /build/src/Functions/FunctionBinaryArithmetic.h:848: bool DB::FunctionBinaryArithmetic::castType::castBothTypes::getReturnTypeImplStatic(std::vector, std::allocator>> const&, std::shared_ptr)::'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&&) @ 0x000000000b5e62cb 6. /build/src/Functions/FunctionBinaryArithmetic.h:846: bool DB::FunctionBinaryArithmetic::castType::castBothTypes::getReturnTypeImplStatic(std::vector, std::allocator>> const&, std::shared_ptr)::'lambda'(auto const&, auto const&)>(DB::IDataType const*, DB::IDataType const*, auto&&)::'lambda'(auto const&)>(DB::IDataType const*, auto&&) @ 0x000000000b5dd2e3 7. /build/src/Functions/FunctionBinaryArithmetic.h:844: DB::FunctionBinaryArithmetic::getReturnTypeImplStatic(std::vector, std::allocator>> const&, std::shared_ptr) @ 0x000000000b5dc43e 8. /build/src/Functions/IFunction.h:369: DB::IFunctionOverloadResolver::getReturnTypeImpl(std::vector> const&) const @ 0x000000000a6646de 9. /build/src/Functions/IFunction.cpp:645: DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x0000000012d96b0c 10. /build/src/Functions/IFunction.cpp:577: DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x0000000012d9669c 11. /build/src/Functions/IFunction.cpp:606: DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x0000000012d96edc 12. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3544: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000014033cc9 13. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3838: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000014019a9e 14. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3980: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000014018e31 15. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:4304: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000014042fa7 16. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5605: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000014013749 17. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000140127f9 18. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000014011fce 19. /build/src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000001406ce8a 20. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000014973b42 21. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000001497268d 22. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000014974d24 23. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001492924b 24. /build/src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88641 25. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 26. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 27. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 28. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 29. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 30. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 31. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 2025.07.28 11:53:28.676269 [ 5112 ] {} TCPHandler: Code: 407. DB::Exception: Overflow during decimal division: In scope SELECT toDecimal128(1, 38) / toDecimal128(1, 1) SETTINGS decimal_check_overflow = 1. (DECIMAL_OVERFLOW), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000000a074fcb 4. /build/src/Functions/FunctionBinaryArithmetic.h:1888: auto DB::FunctionBinaryArithmetic::getReturnTypeImplStatic(std::vector, std::allocator>> const&, std::shared_ptr)::'lambda'(auto const&, auto const&)::operator()>>, DB::DataTypeDecimal>>>(auto const&, auto const&) const @ 0x000000000b5e69d9 5. /build/src/Functions/FunctionBinaryArithmetic.h:848: bool DB::FunctionBinaryArithmetic::castType::castBothTypes::getReturnTypeImplStatic(std::vector, std::allocator>> const&, std::shared_ptr)::'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&&) @ 0x000000000b5e62cb 6. /build/src/Functions/FunctionBinaryArithmetic.h:846: bool DB::FunctionBinaryArithmetic::castType::castBothTypes::getReturnTypeImplStatic(std::vector, std::allocator>> const&, std::shared_ptr)::'lambda'(auto const&, auto const&)>(DB::IDataType const*, DB::IDataType const*, auto&&)::'lambda'(auto const&)>(DB::IDataType const*, auto&&) @ 0x000000000b5dd2e3 7. /build/src/Functions/FunctionBinaryArithmetic.h:844: DB::FunctionBinaryArithmetic::getReturnTypeImplStatic(std::vector, std::allocator>> const&, std::shared_ptr) @ 0x000000000b5dc43e 8. /build/src/Functions/IFunction.h:369: DB::IFunctionOverloadResolver::getReturnTypeImpl(std::vector> const&) const @ 0x000000000a6646de 9. /build/src/Functions/IFunction.cpp:645: DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x0000000012d96b0c 10. /build/src/Functions/IFunction.cpp:577: DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x0000000012d9669c 11. /build/src/Functions/IFunction.cpp:606: DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x0000000012d96edc 12. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3544: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000014033cc9 13. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3838: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000014019a9e 14. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3980: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000014018e31 15. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:4304: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000014042fa7 16. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5605: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000014013749 17. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000140127f9 18. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000014011fce 19. /build/src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000001406ce8a 20. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000014973b42 21. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000001497268d 22. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000014974d24 23. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001492924b 24. /build/src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88641 25. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 26. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 27. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 28. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 29. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 30. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 31. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 2025.07.28 11:53:29.128694 [ 17255 ] {} 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. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception>&, String>(int, FormatStringHelperImpl>&>::type, std::type_identity::type>, std::basic_string_view>&, String&&) @ 0x000000001385a5eb 4. /build/src/Access/SettingsConstraints.cpp:376: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000013859b18 5. /build/src/Access/SettingsConstraints.cpp:300: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000013858faf 6. /build/src/Access/SettingsConstraints.cpp:209: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000013859223 7. /build/src/Interpreters/Context.cpp:2690: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000014436134 8. /build/src/Interpreters/Context.cpp:2729: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x000000001443662b 9. /build/src/Server/HTTPHandler.cpp:457: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000001686d165 10. /build/src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x0000000016870807 11. /build/src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x0000000016907e99 12. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 13. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 14. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 15. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 16. ? @ 0x00007fbc6213eac3 17. ? @ 0x00007fbc621d0850 (version 25.3.6.10636.altinitytest (altinity build)) 2025.07.28 11:53:29.297167 [ 5112 ] {22f31af4-972a-4409-957d-035f4efacd41} executeQuery: Code: 407. DB::Exception: Overflow during decimal division: In scope SELECT toDecimal128(1, 20) / toDecimal128(1, 19) SETTINGS decimal_check_overflow = 1. (DECIMAL_OVERFLOW) (version 25.3.6.10636.altinitytest (altinity build)) (from [::1]:48688) (comment: 00700_decimal_arithm.sql) (query 60, line 92) (in query: SELECT toDecimal128(1, 20) / toDecimal128(1, 19) SETTINGS decimal_check_overflow=1;), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000000a074fcb 4. /build/src/Functions/FunctionBinaryArithmetic.h:1888: auto DB::FunctionBinaryArithmetic::getReturnTypeImplStatic(std::vector, std::allocator>> const&, std::shared_ptr)::'lambda'(auto const&, auto const&)::operator()>>, DB::DataTypeDecimal>>>(auto const&, auto const&) const @ 0x000000000b5e69d9 5. /build/src/Functions/FunctionBinaryArithmetic.h:848: bool DB::FunctionBinaryArithmetic::castType::castBothTypes::getReturnTypeImplStatic(std::vector, std::allocator>> const&, std::shared_ptr)::'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&&) @ 0x000000000b5e62cb 6. /build/src/Functions/FunctionBinaryArithmetic.h:846: bool DB::FunctionBinaryArithmetic::castType::castBothTypes::getReturnTypeImplStatic(std::vector, std::allocator>> const&, std::shared_ptr)::'lambda'(auto const&, auto const&)>(DB::IDataType const*, DB::IDataType const*, auto&&)::'lambda'(auto const&)>(DB::IDataType const*, auto&&) @ 0x000000000b5dd2e3 7. /build/src/Functions/FunctionBinaryArithmetic.h:844: DB::FunctionBinaryArithmetic::getReturnTypeImplStatic(std::vector, std::allocator>> const&, std::shared_ptr) @ 0x000000000b5dc43e 8. /build/src/Functions/IFunction.h:369: DB::IFunctionOverloadResolver::getReturnTypeImpl(std::vector> const&) const @ 0x000000000a6646de 9. /build/src/Functions/IFunction.cpp:645: DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x0000000012d96b0c 10. /build/src/Functions/IFunction.cpp:577: DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x0000000012d9669c 11. /build/src/Functions/IFunction.cpp:606: DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x0000000012d96edc 12. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3544: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000014033cc9 13. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3838: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000014019a9e 14. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3980: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000014018e31 15. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:4304: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000014042fa7 16. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5605: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000014013749 17. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000140127f9 18. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000014011fce 19. /build/src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000001406ce8a 20. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000014973b42 21. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000001497268d 22. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000014974d24 23. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001492924b 24. /build/src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88641 25. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 26. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 27. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 28. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 29. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 30. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 31. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 2025.07.28 11:53:29.322383 [ 5112 ] {} TCPHandler: Code: 407. DB::Exception: Overflow during decimal division: In scope SELECT toDecimal128(1, 20) / toDecimal128(1, 19) SETTINGS decimal_check_overflow = 1. (DECIMAL_OVERFLOW), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000000a074fcb 4. /build/src/Functions/FunctionBinaryArithmetic.h:1888: auto DB::FunctionBinaryArithmetic::getReturnTypeImplStatic(std::vector, std::allocator>> const&, std::shared_ptr)::'lambda'(auto const&, auto const&)::operator()>>, DB::DataTypeDecimal>>>(auto const&, auto const&) const @ 0x000000000b5e69d9 5. /build/src/Functions/FunctionBinaryArithmetic.h:848: bool DB::FunctionBinaryArithmetic::castType::castBothTypes::getReturnTypeImplStatic(std::vector, std::allocator>> const&, std::shared_ptr)::'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&&) @ 0x000000000b5e62cb 6. /build/src/Functions/FunctionBinaryArithmetic.h:846: bool DB::FunctionBinaryArithmetic::castType::castBothTypes::getReturnTypeImplStatic(std::vector, std::allocator>> const&, std::shared_ptr)::'lambda'(auto const&, auto const&)>(DB::IDataType const*, DB::IDataType const*, auto&&)::'lambda'(auto const&)>(DB::IDataType const*, auto&&) @ 0x000000000b5dd2e3 7. /build/src/Functions/FunctionBinaryArithmetic.h:844: DB::FunctionBinaryArithmetic::getReturnTypeImplStatic(std::vector, std::allocator>> const&, std::shared_ptr) @ 0x000000000b5dc43e 8. /build/src/Functions/IFunction.h:369: DB::IFunctionOverloadResolver::getReturnTypeImpl(std::vector> const&) const @ 0x000000000a6646de 9. /build/src/Functions/IFunction.cpp:645: DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x0000000012d96b0c 10. /build/src/Functions/IFunction.cpp:577: DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x0000000012d9669c 11. /build/src/Functions/IFunction.cpp:606: DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x0000000012d96edc 12. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3544: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000014033cc9 13. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3838: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000014019a9e 14. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3980: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000014018e31 15. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:4304: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000014042fa7 16. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5605: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000014013749 17. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000140127f9 18. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000014011fce 19. /build/src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000001406ce8a 20. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000014973b42 21. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000001497268d 22. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000014974d24 23. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001492924b 24. /build/src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88641 25. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 26. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 27. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 28. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 29. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 30. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 31. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 2025.07.28 11:53:29.549278 [ 3971 ] {} test_13.rmt2 (7f9b740d-015c-470e-8cc6-8ba33be0dc63): auto DB::StorageReplicatedMergeTree::processQueueEntry(ReplicatedMergeTreeQueue::SelectedEntryPtr)::(anonymous class)::operator()(LogEntryPtr &) const: Code: 86. DB::HTTPException: Received error from remote server http://146b4357c08d:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Ftest%2F01165%2Ftest_13%2Frmt%2Freplicas%2F1&part=20250728_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.6.10636.altinitytest (altinity build)) '. (RECEIVED_ERROR_FROM_REMOTE_IO_SERVER), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.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 const&, int&&, String const&, unsigned long&&, String const&) @ 0x000000000feda8d9 4. /build/src/IO/HTTPCommon.cpp:104: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x000000000feda6e2 5. /build/src/IO/HTTPCommon.cpp:93: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x000000000feda537 6. /build/src/IO/ReadWriteBufferFromHTTP.cpp:277: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x000000001184a4c4 7. /build/src/IO/ReadWriteBufferFromHTTP.cpp:285: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x000000001184a615 8. /build/src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x000000001184ae59 9. /build/src/IO/ReadWriteBufferFromHTTP.cpp:472: void std::__function::__policy_invoker::__call_impl[abi:se190107]>(std::__function::__policy_storage const*) @ 0x000000001184cedd 10. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001184858b 11. /build/src/IO/ReadWriteBufferFromHTTP.cpp:465: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x000000001184bf0b 12. /build/src/IO/ReadBuffer.h:60: DB::ReadBuffer::next() @ 0x000000000a148c7b 13. /build/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) @ 0x0000000011849fb2 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]>&)>&, 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&) @ 0x0000000011841980 15. /build/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) @ 0x000000001621208e 16. /build/src/Storages/StorageReplicatedMergeTree.cpp:5228: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl[abi:se190107] const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000015f9a5fe 17. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000015ed8bfd 18. /build/src/Storages/StorageReplicatedMergeTree.cpp:2514: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x0000000015ec9aab 19. /build/src/Storages/StorageReplicatedMergeTree.cpp:2349: DB::StorageReplicatedMergeTree::executeLogEntry(DB::ReplicatedMergeTreeLogEntry&) @ 0x0000000015eba91b 20. /build/src/Storages/StorageReplicatedMergeTree.cpp:3876: bool std::__function::__policy_invoker&)>::__call_impl[abi:se190107])::$_1, bool (std::shared_ptr&)>>(std::__function::__policy_storage const*, std::shared_ptr&) @ 0x0000000015f9837e 21. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000165d6fc3 22. /build/src/Storages/StorageReplicatedMergeTree.cpp:3872: DB::StorageReplicatedMergeTree::processQueueEntry(std::shared_ptr) @ 0x0000000015efc18a 23. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001624c1b2 24. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000162f9c70 25. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x00000000162fa55a 26. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc6653 27. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000000fccc4c3 28. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc3d92 29. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fcca080 30. ? @ 0x00007fbc6213eac3 31. ? @ 0x00007fbc621d0850 (version 25.3.6.10636.altinitytest (altinity build)) 2025.07.28 11:53:30.678437 [ 3967 ] {} test_13.rmt2 (7f9b740d-015c-470e-8cc6-8ba33be0dc63): auto DB::StorageReplicatedMergeTree::processQueueEntry(ReplicatedMergeTreeQueue::SelectedEntryPtr)::(anonymous class)::operator()(LogEntryPtr &) const: Code: 86. DB::HTTPException: Received error from remote server http://146b4357c08d:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Ftest%2F01165%2Ftest_13%2Frmt%2Freplicas%2F1&part=20250728_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.6.10636.altinitytest (altinity build)) '. (RECEIVED_ERROR_FROM_REMOTE_IO_SERVER), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.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 const&, int&&, String const&, unsigned long&&, String const&) @ 0x000000000feda8d9 4. /build/src/IO/HTTPCommon.cpp:104: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x000000000feda6e2 5. /build/src/IO/HTTPCommon.cpp:93: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x000000000feda537 6. /build/src/IO/ReadWriteBufferFromHTTP.cpp:277: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x000000001184a4c4 7. /build/src/IO/ReadWriteBufferFromHTTP.cpp:285: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x000000001184a615 8. /build/src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x000000001184ae59 9. /build/src/IO/ReadWriteBufferFromHTTP.cpp:472: void std::__function::__policy_invoker::__call_impl[abi:se190107]>(std::__function::__policy_storage const*) @ 0x000000001184cedd 10. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001184858b 11. /build/src/IO/ReadWriteBufferFromHTTP.cpp:465: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x000000001184bf0b 12. /build/src/IO/ReadBuffer.h:60: DB::ReadBuffer::next() @ 0x000000000a148c7b 13. /build/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) @ 0x0000000011849fb2 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]>&)>&, 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&) @ 0x0000000011841980 15. /build/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) @ 0x000000001621208e 16. /build/src/Storages/StorageReplicatedMergeTree.cpp:5228: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl[abi:se190107] const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000015f9a5fe 17. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000015ed8bfd 18. /build/src/Storages/StorageReplicatedMergeTree.cpp:2514: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x0000000015ec9aab 19. /build/src/Storages/StorageReplicatedMergeTree.cpp:2349: DB::StorageReplicatedMergeTree::executeLogEntry(DB::ReplicatedMergeTreeLogEntry&) @ 0x0000000015eba91b 20. /build/src/Storages/StorageReplicatedMergeTree.cpp:3876: bool std::__function::__policy_invoker&)>::__call_impl[abi:se190107])::$_1, bool (std::shared_ptr&)>>(std::__function::__policy_storage const*, std::shared_ptr&) @ 0x0000000015f9837e 21. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000165d6fc3 22. /build/src/Storages/StorageReplicatedMergeTree.cpp:3872: DB::StorageReplicatedMergeTree::processQueueEntry(std::shared_ptr) @ 0x0000000015efc18a 23. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001624c1b2 24. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000162f9c70 25. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x00000000162fa55a 26. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc6653 27. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000000fccc4c3 28. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc3d92 29. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fcca080 30. ? @ 0x00007fbc6213eac3 31. ? @ 0x00007fbc621d0850 (version 25.3.6.10636.altinitytest (altinity build)) 2025.07.28 11:53:30.954454 [ 3965 ] {} test_13.rmt2 (7f9b740d-015c-470e-8cc6-8ba33be0dc63): auto DB::StorageReplicatedMergeTree::processQueueEntry(ReplicatedMergeTreeQueue::SelectedEntryPtr)::(anonymous class)::operator()(LogEntryPtr &) const: Code: 86. DB::HTTPException: Received error from remote server http://146b4357c08d:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Ftest%2F01165%2Ftest_13%2Frmt%2Freplicas%2F1&part=20250728_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.6.10636.altinitytest (altinity build)) '. (RECEIVED_ERROR_FROM_REMOTE_IO_SERVER), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.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 const&, int&&, String const&, unsigned long&&, String const&) @ 0x000000000feda8d9 4. /build/src/IO/HTTPCommon.cpp:104: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x000000000feda6e2 5. /build/src/IO/HTTPCommon.cpp:93: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x000000000feda537 6. /build/src/IO/ReadWriteBufferFromHTTP.cpp:277: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x000000001184a4c4 7. /build/src/IO/ReadWriteBufferFromHTTP.cpp:285: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x000000001184a615 8. /build/src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x000000001184ae59 9. /build/src/IO/ReadWriteBufferFromHTTP.cpp:472: void std::__function::__policy_invoker::__call_impl[abi:se190107]>(std::__function::__policy_storage const*) @ 0x000000001184cedd 10. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001184858b 11. /build/src/IO/ReadWriteBufferFromHTTP.cpp:465: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x000000001184bf0b 12. /build/src/IO/ReadBuffer.h:60: DB::ReadBuffer::next() @ 0x000000000a148c7b 13. /build/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) @ 0x0000000011849fb2 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]>&)>&, 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&) @ 0x0000000011841980 15. /build/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) @ 0x000000001621208e 16. /build/src/Storages/StorageReplicatedMergeTree.cpp:5228: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl[abi:se190107] const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000015f9a5fe 17. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000015ed8bfd 18. /build/src/Storages/StorageReplicatedMergeTree.cpp:2514: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x0000000015ec9aab 19. /build/src/Storages/StorageReplicatedMergeTree.cpp:2349: DB::StorageReplicatedMergeTree::executeLogEntry(DB::ReplicatedMergeTreeLogEntry&) @ 0x0000000015eba91b 20. /build/src/Storages/StorageReplicatedMergeTree.cpp:3876: bool std::__function::__policy_invoker&)>::__call_impl[abi:se190107])::$_1, bool (std::shared_ptr&)>>(std::__function::__policy_storage const*, std::shared_ptr&) @ 0x0000000015f9837e 21. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000165d6fc3 22. /build/src/Storages/StorageReplicatedMergeTree.cpp:3872: DB::StorageReplicatedMergeTree::processQueueEntry(std::shared_ptr) @ 0x0000000015efc18a 23. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001624c1b2 24. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000162f9c70 25. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x00000000162fa55a 26. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc6653 27. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000000fccc4c3 28. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc3d92 29. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fcca080 30. ? @ 0x00007fbc6213eac3 31. ? @ 0x00007fbc621d0850 (version 25.3.6.10636.altinitytest (altinity build)) 2025.07.28 11:53:31.795818 [ 3961 ] {} test_13.rmt2 (7f9b740d-015c-470e-8cc6-8ba33be0dc63): auto DB::StorageReplicatedMergeTree::processQueueEntry(ReplicatedMergeTreeQueue::SelectedEntryPtr)::(anonymous class)::operator()(LogEntryPtr &) const: Code: 86. DB::HTTPException: Received error from remote server http://146b4357c08d:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Ftest%2F01165%2Ftest_13%2Frmt%2Freplicas%2F1&part=20250728_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.6.10636.altinitytest (altinity build)) '. (RECEIVED_ERROR_FROM_REMOTE_IO_SERVER), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.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 const&, int&&, String const&, unsigned long&&, String const&) @ 0x000000000feda8d9 4. /build/src/IO/HTTPCommon.cpp:104: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x000000000feda6e2 5. /build/src/IO/HTTPCommon.cpp:93: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x000000000feda537 6. /build/src/IO/ReadWriteBufferFromHTTP.cpp:277: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x000000001184a4c4 7. /build/src/IO/ReadWriteBufferFromHTTP.cpp:285: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x000000001184a615 8. /build/src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x000000001184ae59 9. /build/src/IO/ReadWriteBufferFromHTTP.cpp:472: void std::__function::__policy_invoker::__call_impl[abi:se190107]>(std::__function::__policy_storage const*) @ 0x000000001184cedd 10. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001184858b 11. /build/src/IO/ReadWriteBufferFromHTTP.cpp:465: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x000000001184bf0b 12. /build/src/IO/ReadBuffer.h:60: DB::ReadBuffer::next() @ 0x000000000a148c7b 13. /build/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) @ 0x0000000011849fb2 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]>&)>&, 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&) @ 0x0000000011841980 15. /build/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) @ 0x000000001621208e 16. /build/src/Storages/StorageReplicatedMergeTree.cpp:5228: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl[abi:se190107] const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000015f9a5fe 17. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000015ed8bfd 18. /build/src/Storages/StorageReplicatedMergeTree.cpp:2514: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x0000000015ec9aab 19. /build/src/Storages/StorageReplicatedMergeTree.cpp:2349: DB::StorageReplicatedMergeTree::executeLogEntry(DB::ReplicatedMergeTreeLogEntry&) @ 0x0000000015eba91b 20. /build/src/Storages/StorageReplicatedMergeTree.cpp:3876: bool std::__function::__policy_invoker&)>::__call_impl[abi:se190107])::$_1, bool (std::shared_ptr&)>>(std::__function::__policy_storage const*, std::shared_ptr&) @ 0x0000000015f9837e 21. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000165d6fc3 22. /build/src/Storages/StorageReplicatedMergeTree.cpp:3872: DB::StorageReplicatedMergeTree::processQueueEntry(std::shared_ptr) @ 0x0000000015efc18a 23. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001624c1b2 24. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000162f9c70 25. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x00000000162fa55a 26. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc6653 27. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000000fccc4c3 28. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc3d92 29. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fcca080 30. ? @ 0x00007fbc6213eac3 31. ? @ 0x00007fbc621d0850 (version 25.3.6.10636.altinitytest (altinity build)) 2025.07.28 11:53:32.074673 [ 3974 ] {} test_13.rmt2 (7f9b740d-015c-470e-8cc6-8ba33be0dc63): auto DB::StorageReplicatedMergeTree::processQueueEntry(ReplicatedMergeTreeQueue::SelectedEntryPtr)::(anonymous class)::operator()(LogEntryPtr &) const: Code: 86. DB::HTTPException: Received error from remote server http://146b4357c08d:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Ftest%2F01165%2Ftest_13%2Frmt%2Freplicas%2F1&part=20250728_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.6.10636.altinitytest (altinity build)) '. (RECEIVED_ERROR_FROM_REMOTE_IO_SERVER), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.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 const&, int&&, String const&, unsigned long&&, String const&) @ 0x000000000feda8d9 4. /build/src/IO/HTTPCommon.cpp:104: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x000000000feda6e2 5. /build/src/IO/HTTPCommon.cpp:93: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x000000000feda537 6. /build/src/IO/ReadWriteBufferFromHTTP.cpp:277: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x000000001184a4c4 7. /build/src/IO/ReadWriteBufferFromHTTP.cpp:285: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x000000001184a615 8. /build/src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x000000001184ae59 9. /build/src/IO/ReadWriteBufferFromHTTP.cpp:472: void std::__function::__policy_invoker::__call_impl[abi:se190107]>(std::__function::__policy_storage const*) @ 0x000000001184cedd 10. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001184858b 11. /build/src/IO/ReadWriteBufferFromHTTP.cpp:465: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x000000001184bf0b 12. /build/src/IO/ReadBuffer.h:60: DB::ReadBuffer::next() @ 0x000000000a148c7b 13. /build/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) @ 0x0000000011849fb2 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]>&)>&, 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&) @ 0x0000000011841980 15. /build/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) @ 0x000000001621208e 16. /build/src/Storages/StorageReplicatedMergeTree.cpp:5228: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl[abi:se190107] const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000015f9a5fe 17. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000015ed8bfd 18. /build/src/Storages/StorageReplicatedMergeTree.cpp:2514: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x0000000015ec9aab 19. /build/src/Storages/StorageReplicatedMergeTree.cpp:2349: DB::StorageReplicatedMergeTree::executeLogEntry(DB::ReplicatedMergeTreeLogEntry&) @ 0x0000000015eba91b 20. /build/src/Storages/StorageReplicatedMergeTree.cpp:3876: bool std::__function::__policy_invoker&)>::__call_impl[abi:se190107])::$_1, bool (std::shared_ptr&)>>(std::__function::__policy_storage const*, std::shared_ptr&) @ 0x0000000015f9837e 21. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000165d6fc3 22. /build/src/Storages/StorageReplicatedMergeTree.cpp:3872: DB::StorageReplicatedMergeTree::processQueueEntry(std::shared_ptr) @ 0x0000000015efc18a 23. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001624c1b2 24. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000162f9c70 25. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x00000000162fa55a 26. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc6653 27. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000000fccc4c3 28. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc3d92 29. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fcca080 30. ? @ 0x00007fbc6213eac3 31. ? @ 0x00007fbc621d0850 (version 25.3.6.10636.altinitytest (altinity build)) 2025.07.28 11:53:32.327793 [ 3285 ] {9dbcc5fa-442e-439e-ba6a-270c2a2c7347} executeQuery: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=826, jobs=800). (CANNOT_SCHEDULE_TASK) (version 25.3.6.10636.altinitytest (altinity build)) (from [::1]:51318) (comment: 00524_time_intervals_months_underflow.sql) (query 44, line 49) (in query: SELECT toDate('2017-01-01') + INTERVAL 1 YEAR AS x;), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000fccaeeb 4. /build/src/Common/ThreadPool.cpp:275: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000fccacb3 5. /build/src/Common/ThreadPool.cpp:323: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fcc4ffc 6. /build/src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000000fcc584d 7. /build/src/Common/ThreadPool.h:279: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x00000000169bf193 8. /build/src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x00000000169bf518 9. /build/src/Server/TCPHandler.cpp:1237: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x00000000168f1525 10. /build/src/Server/TCPHandler.cpp:678: DB::TCPHandler::runImpl() @ 0x00000000168e68e5 11. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 12. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 13. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 14. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 15. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 16. ? @ 0x00007fbc6213eac3 17. ? @ 0x00007fbc621d0850 2025.07.28 11:53:32.330881 [ 3285 ] {} TCPHandler: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=826, jobs=800). (CANNOT_SCHEDULE_TASK), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000fccaeeb 4. /build/src/Common/ThreadPool.cpp:275: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000fccacb3 5. /build/src/Common/ThreadPool.cpp:323: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fcc4ffc 6. /build/src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000000fcc584d 7. /build/src/Common/ThreadPool.h:279: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x00000000169bf193 8. /build/src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x00000000169bf518 9. /build/src/Server/TCPHandler.cpp:1237: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x00000000168f1525 10. /build/src/Server/TCPHandler.cpp:678: DB::TCPHandler::runImpl() @ 0x00000000168e68e5 11. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 12. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 13. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 14. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 15. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 16. ? @ 0x00007fbc6213eac3 17. ? @ 0x00007fbc621d0850 2025.07.28 11:53:32.403550 [ 3972 ] {} test_13.rmt2 (7f9b740d-015c-470e-8cc6-8ba33be0dc63): auto DB::StorageReplicatedMergeTree::processQueueEntry(ReplicatedMergeTreeQueue::SelectedEntryPtr)::(anonymous class)::operator()(LogEntryPtr &) const: Code: 86. DB::HTTPException: Received error from remote server http://146b4357c08d:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Ftest%2F01165%2Ftest_13%2Frmt%2Freplicas%2F1&part=20250728_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.6.10636.altinitytest (altinity build)) '. (RECEIVED_ERROR_FROM_REMOTE_IO_SERVER), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.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 const&, int&&, String const&, unsigned long&&, String const&) @ 0x000000000feda8d9 4. /build/src/IO/HTTPCommon.cpp:104: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x000000000feda6e2 5. /build/src/IO/HTTPCommon.cpp:93: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x000000000feda537 6. /build/src/IO/ReadWriteBufferFromHTTP.cpp:277: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x000000001184a4c4 7. /build/src/IO/ReadWriteBufferFromHTTP.cpp:285: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x000000001184a615 8. /build/src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x000000001184ae59 9. /build/src/IO/ReadWriteBufferFromHTTP.cpp:472: void std::__function::__policy_invoker::__call_impl[abi:se190107]>(std::__function::__policy_storage const*) @ 0x000000001184cedd 10. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001184858b 11. /build/src/IO/ReadWriteBufferFromHTTP.cpp:465: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x000000001184bf0b 12. /build/src/IO/ReadBuffer.h:60: DB::ReadBuffer::next() @ 0x000000000a148c7b 13. /build/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) @ 0x0000000011849fb2 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]>&)>&, 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&) @ 0x0000000011841980 15. /build/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) @ 0x000000001621208e 16. /build/src/Storages/StorageReplicatedMergeTree.cpp:5228: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl[abi:se190107] const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000015f9a5fe 17. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000015ed8bfd 18. /build/src/Storages/StorageReplicatedMergeTree.cpp:2514: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x0000000015ec9aab 19. /build/src/Storages/StorageReplicatedMergeTree.cpp:2349: DB::StorageReplicatedMergeTree::executeLogEntry(DB::ReplicatedMergeTreeLogEntry&) @ 0x0000000015eba91b 20. /build/src/Storages/StorageReplicatedMergeTree.cpp:3876: bool std::__function::__policy_invoker&)>::__call_impl[abi:se190107])::$_1, bool (std::shared_ptr&)>>(std::__function::__policy_storage const*, std::shared_ptr&) @ 0x0000000015f9837e 21. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000165d6fc3 22. /build/src/Storages/StorageReplicatedMergeTree.cpp:3872: DB::StorageReplicatedMergeTree::processQueueEntry(std::shared_ptr) @ 0x0000000015efc18a 23. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001624c1b2 24. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000162f9c70 25. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x00000000162fa55a 26. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc6653 27. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000000fccc4c3 28. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc3d92 29. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fcca080 30. ? @ 0x00007fbc6213eac3 31. ? @ 0x00007fbc621d0850 (version 25.3.6.10636.altinitytest (altinity build)) 2025.07.28 11:53:32.652539 [ 3971 ] {} test_13.rmt2 (7f9b740d-015c-470e-8cc6-8ba33be0dc63): auto DB::StorageReplicatedMergeTree::processQueueEntry(ReplicatedMergeTreeQueue::SelectedEntryPtr)::(anonymous class)::operator()(LogEntryPtr &) const: Code: 86. DB::HTTPException: Received error from remote server http://146b4357c08d:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Ftest%2F01165%2Ftest_13%2Frmt%2Freplicas%2F1&part=20250728_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.6.10636.altinitytest (altinity build)) '. (RECEIVED_ERROR_FROM_REMOTE_IO_SERVER), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.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 const&, int&&, String const&, unsigned long&&, String const&) @ 0x000000000feda8d9 4. /build/src/IO/HTTPCommon.cpp:104: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x000000000feda6e2 5. /build/src/IO/HTTPCommon.cpp:93: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x000000000feda537 6. /build/src/IO/ReadWriteBufferFromHTTP.cpp:277: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x000000001184a4c4 7. /build/src/IO/ReadWriteBufferFromHTTP.cpp:285: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x000000001184a615 8. /build/src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x000000001184ae59 9. /build/src/IO/ReadWriteBufferFromHTTP.cpp:472: void std::__function::__policy_invoker::__call_impl[abi:se190107]>(std::__function::__policy_storage const*) @ 0x000000001184cedd 10. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001184858b 11. /build/src/IO/ReadWriteBufferFromHTTP.cpp:465: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x000000001184bf0b 12. /build/src/IO/ReadBuffer.h:60: DB::ReadBuffer::next() @ 0x000000000a148c7b 13. /build/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) @ 0x0000000011849fb2 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]>&)>&, 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&) @ 0x0000000011841980 15. /build/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) @ 0x000000001621208e 16. /build/src/Storages/StorageReplicatedMergeTree.cpp:5228: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl[abi:se190107] const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000015f9a5fe 17. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000015ed8bfd 18. /build/src/Storages/StorageReplicatedMergeTree.cpp:2514: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x0000000015ec9aab 19. /build/src/Storages/StorageReplicatedMergeTree.cpp:2349: DB::StorageReplicatedMergeTree::executeLogEntry(DB::ReplicatedMergeTreeLogEntry&) @ 0x0000000015eba91b 20. /build/src/Storages/StorageReplicatedMergeTree.cpp:3876: bool std::__function::__policy_invoker&)>::__call_impl[abi:se190107])::$_1, bool (std::shared_ptr&)>>(std::__function::__policy_storage const*, std::shared_ptr&) @ 0x0000000015f9837e 21. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000165d6fc3 22. /build/src/Storages/StorageReplicatedMergeTree.cpp:3872: DB::StorageReplicatedMergeTree::processQueueEntry(std::shared_ptr) @ 0x0000000015efc18a 23. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001624c1b2 24. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000162f9c70 25. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x00000000162fa55a 26. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc6653 27. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000000fccc4c3 28. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc3d92 29. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fcca080 30. ? @ 0x00007fbc6213eac3 31. ? @ 0x00007fbc621d0850 (version 25.3.6.10636.altinitytest (altinity build)) 2025.07.28 11:53:32.834973 [ 3977 ] {} test_13.rmt2 (7f9b740d-015c-470e-8cc6-8ba33be0dc63): auto DB::StorageReplicatedMergeTree::processQueueEntry(ReplicatedMergeTreeQueue::SelectedEntryPtr)::(anonymous class)::operator()(LogEntryPtr &) const: Code: 86. DB::HTTPException: Received error from remote server http://146b4357c08d:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Ftest%2F01165%2Ftest_13%2Frmt%2Freplicas%2F1&part=20250728_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.6.10636.altinitytest (altinity build)) '. (RECEIVED_ERROR_FROM_REMOTE_IO_SERVER), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.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 const&, int&&, String const&, unsigned long&&, String const&) @ 0x000000000feda8d9 4. /build/src/IO/HTTPCommon.cpp:104: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x000000000feda6e2 5. /build/src/IO/HTTPCommon.cpp:93: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x000000000feda537 6. /build/src/IO/ReadWriteBufferFromHTTP.cpp:277: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x000000001184a4c4 7. /build/src/IO/ReadWriteBufferFromHTTP.cpp:285: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x000000001184a615 8. /build/src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x000000001184ae59 9. /build/src/IO/ReadWriteBufferFromHTTP.cpp:472: void std::__function::__policy_invoker::__call_impl[abi:se190107]>(std::__function::__policy_storage const*) @ 0x000000001184cedd 10. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001184858b 11. /build/src/IO/ReadWriteBufferFromHTTP.cpp:465: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x000000001184bf0b 12. /build/src/IO/ReadBuffer.h:60: DB::ReadBuffer::next() @ 0x000000000a148c7b 13. /build/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) @ 0x0000000011849fb2 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]>&)>&, 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&) @ 0x0000000011841980 15. /build/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) @ 0x000000001621208e 16. /build/src/Storages/StorageReplicatedMergeTree.cpp:5228: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl[abi:se190107] const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000015f9a5fe 17. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000015ed8bfd 18. /build/src/Storages/StorageReplicatedMergeTree.cpp:2514: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x0000000015ec9aab 19. /build/src/Storages/StorageReplicatedMergeTree.cpp:2349: DB::StorageReplicatedMergeTree::executeLogEntry(DB::ReplicatedMergeTreeLogEntry&) @ 0x0000000015eba91b 20. /build/src/Storages/StorageReplicatedMergeTree.cpp:3876: bool std::__function::__policy_invoker&)>::__call_impl[abi:se190107])::$_1, bool (std::shared_ptr&)>>(std::__function::__policy_storage const*, std::shared_ptr&) @ 0x0000000015f9837e 21. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000165d6fc3 22. /build/src/Storages/StorageReplicatedMergeTree.cpp:3872: DB::StorageReplicatedMergeTree::processQueueEntry(std::shared_ptr) @ 0x0000000015efc18a 23. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001624c1b2 24. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000162f9c70 25. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x00000000162fa55a 26. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc6653 27. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000000fccc4c3 28. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc3d92 29. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fcca080 30. ? @ 0x00007fbc6213eac3 31. ? @ 0x00007fbc621d0850 (version 25.3.6.10636.altinitytest (altinity build)) 2025.07.28 11:53:33.163162 [ 3969 ] {} test_13.rmt2 (7f9b740d-015c-470e-8cc6-8ba33be0dc63): auto DB::StorageReplicatedMergeTree::processQueueEntry(ReplicatedMergeTreeQueue::SelectedEntryPtr)::(anonymous class)::operator()(LogEntryPtr &) const: Code: 86. DB::HTTPException: Received error from remote server http://146b4357c08d:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Ftest%2F01165%2Ftest_13%2Frmt%2Freplicas%2F1&part=20250728_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.6.10636.altinitytest (altinity build)) '. (RECEIVED_ERROR_FROM_REMOTE_IO_SERVER), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.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 const&, int&&, String const&, unsigned long&&, String const&) @ 0x000000000feda8d9 4. /build/src/IO/HTTPCommon.cpp:104: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x000000000feda6e2 5. /build/src/IO/HTTPCommon.cpp:93: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x000000000feda537 6. /build/src/IO/ReadWriteBufferFromHTTP.cpp:277: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x000000001184a4c4 7. /build/src/IO/ReadWriteBufferFromHTTP.cpp:285: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x000000001184a615 8. /build/src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x000000001184ae59 9. /build/src/IO/ReadWriteBufferFromHTTP.cpp:472: void std::__function::__policy_invoker::__call_impl[abi:se190107]>(std::__function::__policy_storage const*) @ 0x000000001184cedd 10. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001184858b 11. /build/src/IO/ReadWriteBufferFromHTTP.cpp:465: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x000000001184bf0b 12. /build/src/IO/ReadBuffer.h:60: DB::ReadBuffer::next() @ 0x000000000a148c7b 13. /build/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) @ 0x0000000011849fb2 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]>&)>&, 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&) @ 0x0000000011841980 15. /build/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) @ 0x000000001621208e 16. /build/src/Storages/StorageReplicatedMergeTree.cpp:5228: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl[abi:se190107] const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000015f9a5fe 17. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000015ed8bfd 18. /build/src/Storages/StorageReplicatedMergeTree.cpp:2514: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x0000000015ec9aab 19. /build/src/Storages/StorageReplicatedMergeTree.cpp:2349: DB::StorageReplicatedMergeTree::executeLogEntry(DB::ReplicatedMergeTreeLogEntry&) @ 0x0000000015eba91b 20. /build/src/Storages/StorageReplicatedMergeTree.cpp:3876: bool std::__function::__policy_invoker&)>::__call_impl[abi:se190107])::$_1, bool (std::shared_ptr&)>>(std::__function::__policy_storage const*, std::shared_ptr&) @ 0x0000000015f9837e 21. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000165d6fc3 22. /build/src/Storages/StorageReplicatedMergeTree.cpp:3872: DB::StorageReplicatedMergeTree::processQueueEntry(std::shared_ptr) @ 0x0000000015efc18a 23. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001624c1b2 24. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000162f9c70 25. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x00000000162fa55a 26. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc6653 27. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000000fccc4c3 28. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc3d92 29. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fcca080 30. ? @ 0x00007fbc6213eac3 31. ? @ 0x00007fbc621d0850 (version 25.3.6.10636.altinitytest (altinity build)) 2025.07.28 11:53:33.353381 [ 3967 ] {} test_13.rmt2 (7f9b740d-015c-470e-8cc6-8ba33be0dc63): auto DB::StorageReplicatedMergeTree::processQueueEntry(ReplicatedMergeTreeQueue::SelectedEntryPtr)::(anonymous class)::operator()(LogEntryPtr &) const: Code: 86. DB::HTTPException: Received error from remote server http://146b4357c08d:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Ftest%2F01165%2Ftest_13%2Frmt%2Freplicas%2F1&part=20250728_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.6.10636.altinitytest (altinity build)) '. (RECEIVED_ERROR_FROM_REMOTE_IO_SERVER), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.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 const&, int&&, String const&, unsigned long&&, String const&) @ 0x000000000feda8d9 4. /build/src/IO/HTTPCommon.cpp:104: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x000000000feda6e2 5. /build/src/IO/HTTPCommon.cpp:93: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x000000000feda537 6. /build/src/IO/ReadWriteBufferFromHTTP.cpp:277: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x000000001184a4c4 7. /build/src/IO/ReadWriteBufferFromHTTP.cpp:285: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x000000001184a615 8. /build/src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x000000001184ae59 9. /build/src/IO/ReadWriteBufferFromHTTP.cpp:472: void std::__function::__policy_invoker::__call_impl[abi:se190107]>(std::__function::__policy_storage const*) @ 0x000000001184cedd 10. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001184858b 11. /build/src/IO/ReadWriteBufferFromHTTP.cpp:465: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x000000001184bf0b 12. /build/src/IO/ReadBuffer.h:60: DB::ReadBuffer::next() @ 0x000000000a148c7b 13. /build/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) @ 0x0000000011849fb2 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]>&)>&, 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&) @ 0x0000000011841980 15. /build/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) @ 0x000000001621208e 16. /build/src/Storages/StorageReplicatedMergeTree.cpp:5228: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl[abi:se190107] const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000015f9a5fe 17. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000015ed8bfd 18. /build/src/Storages/StorageReplicatedMergeTree.cpp:2514: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x0000000015ec9aab 19. /build/src/Storages/StorageReplicatedMergeTree.cpp:2349: DB::StorageReplicatedMergeTree::executeLogEntry(DB::ReplicatedMergeTreeLogEntry&) @ 0x0000000015eba91b 20. /build/src/Storages/StorageReplicatedMergeTree.cpp:3876: bool std::__function::__policy_invoker&)>::__call_impl[abi:se190107])::$_1, bool (std::shared_ptr&)>>(std::__function::__policy_storage const*, std::shared_ptr&) @ 0x0000000015f9837e 21. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000165d6fc3 22. /build/src/Storages/StorageReplicatedMergeTree.cpp:3872: DB::StorageReplicatedMergeTree::processQueueEntry(std::shared_ptr) @ 0x0000000015efc18a 23. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001624c1b2 24. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000162f9c70 25. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x00000000162fa55a 26. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc6653 27. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000000fccc4c3 28. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc3d92 29. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fcca080 30. ? @ 0x00007fbc6213eac3 31. ? @ 0x00007fbc621d0850 (version 25.3.6.10636.altinitytest (altinity build)) 2025.07.28 11:53:34.179060 [ 3968 ] {} test_13.rmt2 (7f9b740d-015c-470e-8cc6-8ba33be0dc63): auto DB::StorageReplicatedMergeTree::processQueueEntry(ReplicatedMergeTreeQueue::SelectedEntryPtr)::(anonymous class)::operator()(LogEntryPtr &) const: Code: 86. DB::HTTPException: Received error from remote server http://146b4357c08d:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Ftest%2F01165%2Ftest_13%2Frmt%2Freplicas%2F1&part=20250728_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.6.10636.altinitytest (altinity build)) '. (RECEIVED_ERROR_FROM_REMOTE_IO_SERVER), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.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 const&, int&&, String const&, unsigned long&&, String const&) @ 0x000000000feda8d9 4. /build/src/IO/HTTPCommon.cpp:104: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x000000000feda6e2 5. /build/src/IO/HTTPCommon.cpp:93: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x000000000feda537 6. /build/src/IO/ReadWriteBufferFromHTTP.cpp:277: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x000000001184a4c4 7. /build/src/IO/ReadWriteBufferFromHTTP.cpp:285: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x000000001184a615 8. /build/src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x000000001184ae59 9. /build/src/IO/ReadWriteBufferFromHTTP.cpp:472: void std::__function::__policy_invoker::__call_impl[abi:se190107]>(std::__function::__policy_storage const*) @ 0x000000001184cedd 10. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001184858b 11. /build/src/IO/ReadWriteBufferFromHTTP.cpp:465: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x000000001184bf0b 12. /build/src/IO/ReadBuffer.h:60: DB::ReadBuffer::next() @ 0x000000000a148c7b 13. /build/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) @ 0x0000000011849fb2 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]>&)>&, 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&) @ 0x0000000011841980 15. /build/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) @ 0x000000001621208e 16. /build/src/Storages/StorageReplicatedMergeTree.cpp:5228: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl[abi:se190107] const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000015f9a5fe 17. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000015ed8bfd 18. /build/src/Storages/StorageReplicatedMergeTree.cpp:2514: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x0000000015ec9aab 19. /build/src/Storages/StorageReplicatedMergeTree.cpp:2349: DB::StorageReplicatedMergeTree::executeLogEntry(DB::ReplicatedMergeTreeLogEntry&) @ 0x0000000015eba91b 20. /build/src/Storages/StorageReplicatedMergeTree.cpp:3876: bool std::__function::__policy_invoker&)>::__call_impl[abi:se190107])::$_1, bool (std::shared_ptr&)>>(std::__function::__policy_storage const*, std::shared_ptr&) @ 0x0000000015f9837e 21. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000165d6fc3 22. /build/src/Storages/StorageReplicatedMergeTree.cpp:3872: DB::StorageReplicatedMergeTree::processQueueEntry(std::shared_ptr) @ 0x0000000015efc18a 23. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001624c1b2 24. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000162f9c70 25. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x00000000162fa55a 26. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc6653 27. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000000fccc4c3 28. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc3d92 29. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fcca080 30. ? @ 0x00007fbc6213eac3 31. ? @ 0x00007fbc621d0850 (version 25.3.6.10636.altinitytest (altinity build)) 2025.07.28 11:53:34.266576 [ 17321 ] {7c797a90-2324-44d6-9865-167459cc4c63} executeQuery: Code: 27. DB::Exception: Cannot parse input: expected '(' at end of stream.: while converting '' to Tuple(UInt8): In scope SELECT tuple(1) < ''. (CANNOT_PARSE_INPUT_ASSERTION_FAILED) (version 25.3.6.10636.altinitytest (altinity build)) (from [::1]:40126) (comment: 01329_compare_tuple_string_constant.sql) (query 1, line 1) (in query: SELECT tuple(1) < '';), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x000000000a080b2b 4. /build/src/IO/ReadHelpers.cpp:95: DB::throwAtAssertionFailed(char const*, DB::ReadBuffer&) @ 0x000000000fc6bcc9 5. /build/src/IO/ReadHelpers.h:204: void DB::SerializationTuple::deserializeTextImpl(DB::IColumn&, DB::ReadBuffer&, DB::FormatSettings const&, bool) const @ 0x0000000013d22ce5 6. /build/src/Interpreters/convertFieldToType.cpp:578: DB::(anonymous namespace)::convertFieldToTypeImpl(DB::Field const&, DB::IDataType const&, DB::IDataType const*, DB::FormatSettings const&) @ 0x0000000014c596e9 7. /build/src/Interpreters/convertFieldToType.cpp:633: DB::convertFieldToType(DB::Field const&, DB::IDataType const&, DB::IDataType const*, DB::FormatSettings const&) @ 0x0000000014c57687 8. /build/src/Functions/FunctionsComparison.h:925: DB::FunctionComparison::executeWithConstString(std::shared_ptr const&, DB::IColumn const*, DB::IColumn const*, std::shared_ptr const&, std::shared_ptr const&, unsigned long) const @ 0x000000000ca82b51 9. /build/src/Functions/FunctionsComparison.h:1361: DB::FunctionComparison::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000ca69e7f 10. /build/src/Functions/IFunction.h:437: DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000a069f2a 11. /build/src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000012d9965a 12. /build/src/Functions/IFunction.cpp:351: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d93b02 13. /build/src/Functions/IFunction.cpp:420: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d95059 14. /build/src/Functions/IFunction.cpp:498: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d95c72 15. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3567: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000014034494 16. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3838: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000014019a9e 17. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3980: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000014018e31 18. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:4304: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000014042fa7 19. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5605: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000014013749 20. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000140127f9 21. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000014011fce 22. /build/src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000001406ce8a 23. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000014973b42 24. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000001497268d 25. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000014974d24 26. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001492924b 27. /build/src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88641 28. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 29. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 30. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 31. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 2025.07.28 11:53:34.271568 [ 17321 ] {} TCPHandler: Code: 27. DB::Exception: Cannot parse input: expected '(' at end of stream.: while converting '' to Tuple(UInt8): In scope SELECT tuple(1) < ''. (CANNOT_PARSE_INPUT_ASSERTION_FAILED), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x000000000a080b2b 4. /build/src/IO/ReadHelpers.cpp:95: DB::throwAtAssertionFailed(char const*, DB::ReadBuffer&) @ 0x000000000fc6bcc9 5. /build/src/IO/ReadHelpers.h:204: void DB::SerializationTuple::deserializeTextImpl(DB::IColumn&, DB::ReadBuffer&, DB::FormatSettings const&, bool) const @ 0x0000000013d22ce5 6. /build/src/Interpreters/convertFieldToType.cpp:578: DB::(anonymous namespace)::convertFieldToTypeImpl(DB::Field const&, DB::IDataType const&, DB::IDataType const*, DB::FormatSettings const&) @ 0x0000000014c596e9 7. /build/src/Interpreters/convertFieldToType.cpp:633: DB::convertFieldToType(DB::Field const&, DB::IDataType const&, DB::IDataType const*, DB::FormatSettings const&) @ 0x0000000014c57687 8. /build/src/Functions/FunctionsComparison.h:925: DB::FunctionComparison::executeWithConstString(std::shared_ptr const&, DB::IColumn const*, DB::IColumn const*, std::shared_ptr const&, std::shared_ptr const&, unsigned long) const @ 0x000000000ca82b51 9. /build/src/Functions/FunctionsComparison.h:1361: DB::FunctionComparison::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000ca69e7f 10. /build/src/Functions/IFunction.h:437: DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000a069f2a 11. /build/src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000012d9965a 12. /build/src/Functions/IFunction.cpp:351: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d93b02 13. /build/src/Functions/IFunction.cpp:420: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d95059 14. /build/src/Functions/IFunction.cpp:498: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d95c72 15. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3567: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000014034494 16. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3838: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000014019a9e 17. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3980: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000014018e31 18. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:4304: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000014042fa7 19. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5605: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000014013749 20. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000140127f9 21. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000014011fce 22. /build/src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000001406ce8a 23. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000014973b42 24. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000001497268d 25. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000014974d24 26. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001492924b 27. /build/src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88641 28. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 29. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 30. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 31. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 2025.07.28 11:53:34.377450 [ 17321 ] {608c530d-5c42-4be9-ab3d-5c5261513746} executeQuery: Code: 386. DB::Exception: There is no supertype for types Tuple(UInt8), String because some of them are Tuple and some of them are not. (NO_COMMON_TYPE) (version 25.3.6.10636.altinitytest (altinity build)) (from [::1]:40126) (comment: 01329_compare_tuple_string_constant.sql) (query 2, line 2) (in query: SELECT tuple(1) < materialize('');), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception>&>(int, FormatStringHelperImpl::type, std::type_identity>&>::type>, String&&, std::basic_string_view>&) @ 0x000000000de9098b 4. /build/src/DataTypes/getLeastSupertype.cpp:69: std::shared_ptr DB::(anonymous namespace)::throwOrReturn<(DB::LeastSupertypeOnError)0, std::vector, std::allocator>>>(std::vector, std::allocator>> const&, std::basic_string_view>, int) @ 0x0000000013c6a73e 5. /build/src/DataTypes/getLeastSupertype.cpp:401: std::shared_ptr DB::getLeastSupertype<(DB::LeastSupertypeOnError)0>(std::vector, std::allocator>> const&) @ 0x0000000013c6dcdb 6. /build/src/Functions/FunctionsComparison.h:1149: DB::FunctionComparison::executeGeneric(DB::ColumnWithTypeAndName const&, DB::ColumnWithTypeAndName const&) const @ 0x000000000ca83af3 7. /build/src/Functions/FunctionsComparison.h:1429: DB::FunctionComparison::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000ca6aa14 8. /build/src/Functions/IFunction.h:437: DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000a069f2a 9. /build/src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000012d9965a 10. /build/src/Functions/IFunction.cpp:351: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d93b02 11. /build/src/Functions/IFunction.cpp:420: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d95059 12. /build/src/Functions/IFunction.cpp:498: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d95c72 13. /build/src/Interpreters/ActionsDAG.cpp:812: DB::ActionsDAG::evaluatePartialResult(std::unordered_map, std::equal_to, std::allocator>>&, std::vector> const&, unsigned long, bool) @ 0x0000000013fa38cc 14. /build/src/Interpreters/ActionsDAG.cpp:892: DB::ActionsDAG::updateHeader(DB::Block const&) const @ 0x0000000013fa29a8 15. /build/src/Processors/Transforms/ExpressionTransform.cpp:10: DB::ExpressionTransform::transformHeader(DB::Block const&, DB::ActionsDAG const&) @ 0x0000000016c0afd2 16. /build/src/Processors/QueryPlan/ExpressionStep.cpp:38: DB::ExpressionStep::ExpressionStep(DB::Block const&, DB::ActionsDAG) @ 0x0000000016db8ad1 17. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107](DB::Block const&, DB::ActionsDAG&&) @ 0x00000000131ee01a 18. /build/src/Planner/Planner.cpp:392: DB::(anonymous namespace)::addExpressionStep(DB::QueryPlan&, std::shared_ptr&, String const&, std::unordered_set, std::hash>, std::equal_to>, std::allocator>>&) @ 0x000000001498191d 19. /build/src/Planner/Planner.cpp:1648: DB::Planner::buildPlanForQueryNode() @ 0x000000001497b7aa 20. /build/src/Planner/Planner.cpp:1308: DB::Planner::buildQueryPlanIfNeeded() @ 0x000000001497685c 21. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:255: DB::InterpreterSelectQueryAnalyzer::getQueryPlan() @ 0x000000001497476d 22. /build/src/Interpreters/executeQuery.cpp:1405: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88806 23. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 24. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 25. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 26. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 27. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 28. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 29. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 30. ? @ 0x00007fbc6213eac3 31. ? @ 0x00007fbc621d0850 2025.07.28 11:53:34.388553 [ 17321 ] {} TCPHandler: Code: 386. DB::Exception: There is no supertype for types Tuple(UInt8), String because some of them are Tuple and some of them are not. (NO_COMMON_TYPE), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception>&>(int, FormatStringHelperImpl::type, std::type_identity>&>::type>, String&&, std::basic_string_view>&) @ 0x000000000de9098b 4. /build/src/DataTypes/getLeastSupertype.cpp:69: std::shared_ptr DB::(anonymous namespace)::throwOrReturn<(DB::LeastSupertypeOnError)0, std::vector, std::allocator>>>(std::vector, std::allocator>> const&, std::basic_string_view>, int) @ 0x0000000013c6a73e 5. /build/src/DataTypes/getLeastSupertype.cpp:401: std::shared_ptr DB::getLeastSupertype<(DB::LeastSupertypeOnError)0>(std::vector, std::allocator>> const&) @ 0x0000000013c6dcdb 6. /build/src/Functions/FunctionsComparison.h:1149: DB::FunctionComparison::executeGeneric(DB::ColumnWithTypeAndName const&, DB::ColumnWithTypeAndName const&) const @ 0x000000000ca83af3 7. /build/src/Functions/FunctionsComparison.h:1429: DB::FunctionComparison::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000ca6aa14 8. /build/src/Functions/IFunction.h:437: DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000a069f2a 9. /build/src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000012d9965a 10. /build/src/Functions/IFunction.cpp:351: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d93b02 11. /build/src/Functions/IFunction.cpp:420: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d95059 12. /build/src/Functions/IFunction.cpp:498: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d95c72 13. /build/src/Interpreters/ActionsDAG.cpp:812: DB::ActionsDAG::evaluatePartialResult(std::unordered_map, std::equal_to, std::allocator>>&, std::vector> const&, unsigned long, bool) @ 0x0000000013fa38cc 14. /build/src/Interpreters/ActionsDAG.cpp:892: DB::ActionsDAG::updateHeader(DB::Block const&) const @ 0x0000000013fa29a8 15. /build/src/Processors/Transforms/ExpressionTransform.cpp:10: DB::ExpressionTransform::transformHeader(DB::Block const&, DB::ActionsDAG const&) @ 0x0000000016c0afd2 16. /build/src/Processors/QueryPlan/ExpressionStep.cpp:38: DB::ExpressionStep::ExpressionStep(DB::Block const&, DB::ActionsDAG) @ 0x0000000016db8ad1 17. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107](DB::Block const&, DB::ActionsDAG&&) @ 0x00000000131ee01a 18. /build/src/Planner/Planner.cpp:392: DB::(anonymous namespace)::addExpressionStep(DB::QueryPlan&, std::shared_ptr&, String const&, std::unordered_set, std::hash>, std::equal_to>, std::allocator>>&) @ 0x000000001498191d 19. /build/src/Planner/Planner.cpp:1648: DB::Planner::buildPlanForQueryNode() @ 0x000000001497b7aa 20. /build/src/Planner/Planner.cpp:1308: DB::Planner::buildQueryPlanIfNeeded() @ 0x000000001497685c 21. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:255: DB::InterpreterSelectQueryAnalyzer::getQueryPlan() @ 0x000000001497476d 22. /build/src/Interpreters/executeQuery.cpp:1405: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88806 23. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 24. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 25. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 26. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 27. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 28. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 29. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 30. ? @ 0x00007fbc6213eac3 31. ? @ 0x00007fbc621d0850 2025.07.28 11:53:34.825167 [ 3965 ] {} test_13.rmt2 (7f9b740d-015c-470e-8cc6-8ba33be0dc63): auto DB::StorageReplicatedMergeTree::processQueueEntry(ReplicatedMergeTreeQueue::SelectedEntryPtr)::(anonymous class)::operator()(LogEntryPtr &) const: Code: 86. DB::HTTPException: Received error from remote server http://146b4357c08d:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Ftest%2F01165%2Ftest_13%2Frmt%2Freplicas%2F1&part=20250728_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.6.10636.altinitytest (altinity build)) '. (RECEIVED_ERROR_FROM_REMOTE_IO_SERVER), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.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 const&, int&&, String const&, unsigned long&&, String const&) @ 0x000000000feda8d9 4. /build/src/IO/HTTPCommon.cpp:104: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x000000000feda6e2 5. /build/src/IO/HTTPCommon.cpp:93: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x000000000feda537 6. /build/src/IO/ReadWriteBufferFromHTTP.cpp:277: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x000000001184a4c4 7. /build/src/IO/ReadWriteBufferFromHTTP.cpp:285: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x000000001184a615 8. /build/src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x000000001184ae59 9. /build/src/IO/ReadWriteBufferFromHTTP.cpp:472: void std::__function::__policy_invoker::__call_impl[abi:se190107]>(std::__function::__policy_storage const*) @ 0x000000001184cedd 10. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001184858b 11. /build/src/IO/ReadWriteBufferFromHTTP.cpp:465: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x000000001184bf0b 12. /build/src/IO/ReadBuffer.h:60: DB::ReadBuffer::next() @ 0x000000000a148c7b 13. /build/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) @ 0x0000000011849fb2 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]>&)>&, 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&) @ 0x0000000011841980 15. /build/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) @ 0x000000001621208e 16. /build/src/Storages/StorageReplicatedMergeTree.cpp:5228: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl[abi:se190107] const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000015f9a5fe 17. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000015ed8bfd 18. /build/src/Storages/StorageReplicatedMergeTree.cpp:2514: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x0000000015ec9aab 19. /build/src/Storages/StorageReplicatedMergeTree.cpp:2349: DB::StorageReplicatedMergeTree::executeLogEntry(DB::ReplicatedMergeTreeLogEntry&) @ 0x0000000015eba91b 20. /build/src/Storages/StorageReplicatedMergeTree.cpp:3876: bool std::__function::__policy_invoker&)>::__call_impl[abi:se190107])::$_1, bool (std::shared_ptr&)>>(std::__function::__policy_storage const*, std::shared_ptr&) @ 0x0000000015f9837e 21. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000165d6fc3 22. /build/src/Storages/StorageReplicatedMergeTree.cpp:3872: DB::StorageReplicatedMergeTree::processQueueEntry(std::shared_ptr) @ 0x0000000015efc18a 23. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001624c1b2 24. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000162f9c70 25. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x00000000162fa55a 26. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc6653 27. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000000fccc4c3 28. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc3d92 29. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fcca080 30. ? @ 0x00007fbc6213eac3 31. ? @ 0x00007fbc621d0850 (version 25.3.6.10636.altinitytest (altinity build)) 2025.07.28 11:53:34.990026 [ 5959 ] {} ExternalDictionariesLoader: Could not load external dictionary 'cc8b1a52-da70-449c-9c23-8d623c5fcc44', next update is scheduled at 2025-07-28 11:53:46: Code: 396. DB::Exception: Limit for result exceeded, max bytes: 1.00 B, current bytes: 36.00 B. (TOO_MANY_ROWS_OR_BYTES), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, char const*&, ReadableSize&&, ReadableSize&&) @ 0x0000000013bd4eeb 4. /build/src/QueryPipeline/SizeLimits.cpp:43: DB::SizeLimits::check(unsigned long, unsigned long, char const*, int, int) const @ 0x0000000013bd48a1 5. /build/src/Processors/Transforms/LimitsCheckingTransform.cpp:45: DB::LimitsCheckingTransform::transform(DB::Chunk&) @ 0x0000000016c1d2fb 6. /build/src/Processors/ISimpleTransform.h:33: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000011a9a453 7. /build/src/Processors/ISimpleTransform.cpp:89: DB::ISimpleTransform::work() @ 0x000000001699fca0 8. /build/src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x00000000169bd00f 9. /build/src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x00000000169b2105 10. /build/src/Processors/Executors/PipelineExecutor.cpp:170: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x00000000169b16a7 11. /build/src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x00000000169c081c 12. /build/src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x00000000169c0978 13. /build/src/Dictionaries/FlatDictionary.cpp:502: DB::FlatDictionary::loadData() @ 0x0000000011b424cb 14. /build/src/Dictionaries/FlatDictionary.cpp:46: DB::FlatDictionary::FlatDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, DB::FlatDictionary::Configuration, std::shared_ptr) @ 0x0000000011b42111 15. /build/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:se190107]> (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) @ 0x0000000011b5d3e2 16. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000012d8a61d 17. /build/src/Interpreters/ExternalDictionariesLoader.cpp:47: DB::ExternalDictionariesLoader::createObject(String const&, Poco::Util::AbstractConfiguration const&, String const&, String const&) const @ 0x00000000148a6f44 18. /build/src/Interpreters/ExternalLoader.cpp:1522: DB::ExternalLoader::LoadingDispatcher::loadSingleObject(String const&, DB::ExternalLoader::ObjectConfig const&, std::shared_ptr) @ 0x00000000148b2ee8 19. /build/src/Interpreters/ExternalLoader.cpp:998: DB::ExternalLoader::LoadingDispatcher::doLoading(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr) @ 0x00000000148b197d 20. /build/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()() @ 0x00000000148b5991 21. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc3d92 22. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fcca080 23. ? @ 0x00007fbc6213eac3 24. ? @ 0x00007fbc621d0850 (version 25.3.6.10636.altinitytest (altinity build)) 2025.07.28 11:53:35.270934 [ 3977 ] {} test_13.rmt2 (7f9b740d-015c-470e-8cc6-8ba33be0dc63): auto DB::StorageReplicatedMergeTree::processQueueEntry(ReplicatedMergeTreeQueue::SelectedEntryPtr)::(anonymous class)::operator()(LogEntryPtr &) const: Code: 86. DB::HTTPException: Received error from remote server http://146b4357c08d:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Ftest%2F01165%2Ftest_13%2Frmt%2Freplicas%2F1&part=20250728_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.6.10636.altinitytest (altinity build)) '. (RECEIVED_ERROR_FROM_REMOTE_IO_SERVER), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.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 const&, int&&, String const&, unsigned long&&, String const&) @ 0x000000000feda8d9 4. /build/src/IO/HTTPCommon.cpp:104: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x000000000feda6e2 5. /build/src/IO/HTTPCommon.cpp:93: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x000000000feda537 6. /build/src/IO/ReadWriteBufferFromHTTP.cpp:277: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x000000001184a4c4 7. /build/src/IO/ReadWriteBufferFromHTTP.cpp:285: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x000000001184a615 8. /build/src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x000000001184ae59 9. /build/src/IO/ReadWriteBufferFromHTTP.cpp:472: void std::__function::__policy_invoker::__call_impl[abi:se190107]>(std::__function::__policy_storage const*) @ 0x000000001184cedd 10. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001184858b 11. /build/src/IO/ReadWriteBufferFromHTTP.cpp:465: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x000000001184bf0b 12. /build/src/IO/ReadBuffer.h:60: DB::ReadBuffer::next() @ 0x000000000a148c7b 13. /build/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) @ 0x0000000011849fb2 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]>&)>&, 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&) @ 0x0000000011841980 15. /build/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) @ 0x000000001621208e 16. /build/src/Storages/StorageReplicatedMergeTree.cpp:5228: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl[abi:se190107] const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000015f9a5fe 17. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000015ed8bfd 18. /build/src/Storages/StorageReplicatedMergeTree.cpp:2514: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x0000000015ec9aab 19. /build/src/Storages/StorageReplicatedMergeTree.cpp:2349: DB::StorageReplicatedMergeTree::executeLogEntry(DB::ReplicatedMergeTreeLogEntry&) @ 0x0000000015eba91b 20. /build/src/Storages/StorageReplicatedMergeTree.cpp:3876: bool std::__function::__policy_invoker&)>::__call_impl[abi:se190107])::$_1, bool (std::shared_ptr&)>>(std::__function::__policy_storage const*, std::shared_ptr&) @ 0x0000000015f9837e 21. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000165d6fc3 22. /build/src/Storages/StorageReplicatedMergeTree.cpp:3872: DB::StorageReplicatedMergeTree::processQueueEntry(std::shared_ptr) @ 0x0000000015efc18a 23. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001624c1b2 24. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000162f9c70 25. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x00000000162fa55a 26. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc6653 27. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000000fccc4c3 28. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc3d92 29. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fcca080 30. ? @ 0x00007fbc6213eac3 31. ? @ 0x00007fbc621d0850 (version 25.3.6.10636.altinitytest (altinity build)) 2025.07.28 11:53:35.427922 [ 5879 ] {328501d7-ecb6-4939-9e4d-9288a2fdaa63} executeQuery: Code: 43. DB::Exception: A value of illegal type was provided as 1st argument 'year' to function 'makeDate32'. Expected: Number, got: Date: In scope SELECT makeDate32(CAST(1980, 'Date'), 10, 30). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.6.10636.altinitytest (altinity build)) (from [::1]:40084) (comment: 02243_make_date32.sql) (query 18, line 20) (in query: select makeDate32(cast(1980 as Date), 10, 30);), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: 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&&) @ 0x0000000012da74d9 4. /build/src/Functions/FunctionHelpers.cpp:130: DB::(anonymous namespace)::validateArgumentsImpl(DB::IFunction const&, std::vector> const&, unsigned long, std::vector> const&) @ 0x0000000012da5b15 5. /build/src/Functions/FunctionHelpers.cpp:192: DB::validateFunctionArguments(DB::IFunction const&, std::vector> const&, std::vector> const&, std::vector> const&) @ 0x0000000012da54fb 6. /build/src/Functions/makeDate.cpp:91: DB::(anonymous namespace)::FunctionMakeDate::getReturnTypeImpl(std::vector> const&) const @ 0x000000000cf7c834 7. /build/src/Functions/IFunction.cpp:645: DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x0000000012d96b0c 8. /build/src/Functions/IFunction.cpp:577: DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x0000000012d9669c 9. /build/src/Functions/IFunction.cpp:606: DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x0000000012d96edc 10. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3544: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000014033cc9 11. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3838: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000014019a9e 12. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3980: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000014018e31 13. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:4304: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000014042fa7 14. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5605: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000014013749 15. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000140127f9 16. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000014011fce 17. /build/src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000001406ce8a 18. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000014973b42 19. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000001497268d 20. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000014974d24 21. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001492924b 22. /build/src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88641 23. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 24. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 25. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 26. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 27. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 28. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 29. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 30. ? @ 0x00007fbc6213eac3 31. ? @ 0x00007fbc621d0850 2025.07.28 11:53:35.446714 [ 5879 ] {} TCPHandler: Code: 43. DB::Exception: A value of illegal type was provided as 1st argument 'year' to function 'makeDate32'. Expected: Number, got: Date: In scope SELECT makeDate32(CAST(1980, 'Date'), 10, 30). (ILLEGAL_TYPE_OF_ARGUMENT), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: 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&&) @ 0x0000000012da74d9 4. /build/src/Functions/FunctionHelpers.cpp:130: DB::(anonymous namespace)::validateArgumentsImpl(DB::IFunction const&, std::vector> const&, unsigned long, std::vector> const&) @ 0x0000000012da5b15 5. /build/src/Functions/FunctionHelpers.cpp:192: DB::validateFunctionArguments(DB::IFunction const&, std::vector> const&, std::vector> const&, std::vector> const&) @ 0x0000000012da54fb 6. /build/src/Functions/makeDate.cpp:91: DB::(anonymous namespace)::FunctionMakeDate::getReturnTypeImpl(std::vector> const&) const @ 0x000000000cf7c834 7. /build/src/Functions/IFunction.cpp:645: DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x0000000012d96b0c 8. /build/src/Functions/IFunction.cpp:577: DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x0000000012d9669c 9. /build/src/Functions/IFunction.cpp:606: DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x0000000012d96edc 10. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3544: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000014033cc9 11. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3838: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000014019a9e 12. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3980: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000014018e31 13. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:4304: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000014042fa7 14. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5605: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000014013749 15. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000140127f9 16. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000014011fce 17. /build/src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000001406ce8a 18. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000014973b42 19. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000001497268d 20. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000014974d24 21. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001492924b 22. /build/src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88641 23. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 24. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 25. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 26. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 27. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 28. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 29. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 30. ? @ 0x00007fbc6213eac3 31. ? @ 0x00007fbc621d0850 2025.07.28 11:53:35.507126 [ 5879 ] {1ea78b2e-341d-476d-86d4-5dd58a5b20df} executeQuery: Code: 43. DB::Exception: A value of illegal type was provided as 1st argument 'year' to function 'makeDate32'. Expected: Number, got: Date: In scope SELECT makeDate32(CAST(-1980, 'Date'), 10, 30). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.6.10636.altinitytest (altinity build)) (from [::1]:40084) (comment: 02243_make_date32.sql) (query 19, line 21) (in query: select makeDate32(cast(-1980 as Date), 10, 30);), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: 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&&) @ 0x0000000012da74d9 4. /build/src/Functions/FunctionHelpers.cpp:130: DB::(anonymous namespace)::validateArgumentsImpl(DB::IFunction const&, std::vector> const&, unsigned long, std::vector> const&) @ 0x0000000012da5b15 5. /build/src/Functions/FunctionHelpers.cpp:192: DB::validateFunctionArguments(DB::IFunction const&, std::vector> const&, std::vector> const&, std::vector> const&) @ 0x0000000012da54fb 6. /build/src/Functions/makeDate.cpp:91: DB::(anonymous namespace)::FunctionMakeDate::getReturnTypeImpl(std::vector> const&) const @ 0x000000000cf7c834 7. /build/src/Functions/IFunction.cpp:645: DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x0000000012d96b0c 8. /build/src/Functions/IFunction.cpp:577: DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x0000000012d9669c 9. /build/src/Functions/IFunction.cpp:606: DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x0000000012d96edc 10. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3544: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000014033cc9 11. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3838: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000014019a9e 12. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3980: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000014018e31 13. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:4304: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000014042fa7 14. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5605: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000014013749 15. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000140127f9 16. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000014011fce 17. /build/src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000001406ce8a 18. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000014973b42 19. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000001497268d 20. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000014974d24 21. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001492924b 22. /build/src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88641 23. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 24. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 25. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 26. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 27. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 28. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 29. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 30. ? @ 0x00007fbc6213eac3 31. ? @ 0x00007fbc621d0850 2025.07.28 11:53:35.512823 [ 5879 ] {} TCPHandler: Code: 43. DB::Exception: A value of illegal type was provided as 1st argument 'year' to function 'makeDate32'. Expected: Number, got: Date: In scope SELECT makeDate32(CAST(-1980, 'Date'), 10, 30). (ILLEGAL_TYPE_OF_ARGUMENT), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: 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&&) @ 0x0000000012da74d9 4. /build/src/Functions/FunctionHelpers.cpp:130: DB::(anonymous namespace)::validateArgumentsImpl(DB::IFunction const&, std::vector> const&, unsigned long, std::vector> const&) @ 0x0000000012da5b15 5. /build/src/Functions/FunctionHelpers.cpp:192: DB::validateFunctionArguments(DB::IFunction const&, std::vector> const&, std::vector> const&, std::vector> const&) @ 0x0000000012da54fb 6. /build/src/Functions/makeDate.cpp:91: DB::(anonymous namespace)::FunctionMakeDate::getReturnTypeImpl(std::vector> const&) const @ 0x000000000cf7c834 7. /build/src/Functions/IFunction.cpp:645: DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x0000000012d96b0c 8. /build/src/Functions/IFunction.cpp:577: DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x0000000012d9669c 9. /build/src/Functions/IFunction.cpp:606: DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x0000000012d96edc 10. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3544: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000014033cc9 11. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3838: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000014019a9e 12. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3980: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000014018e31 13. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:4304: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000014042fa7 14. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5605: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000014013749 15. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000140127f9 16. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000014011fce 17. /build/src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000001406ce8a 18. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000014973b42 19. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000001497268d 20. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000014974d24 21. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001492924b 22. /build/src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88641 23. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 24. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 25. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 26. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 27. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 28. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 29. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 30. ? @ 0x00007fbc6213eac3 31. ? @ 0x00007fbc621d0850 2025.07.28 11:53:35.550775 [ 5879 ] {ecc7c5c3-2574-43cb-906a-6178f8576cc0} executeQuery: Code: 43. DB::Exception: A value of illegal type was provided as 1st argument 'year' to function 'makeDate32'. Expected: Number, got: Date32: In scope SELECT makeDate32(CAST(1980, 'Date32'), 10, 30). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.6.10636.altinitytest (altinity build)) (from [::1]:40084) (comment: 02243_make_date32.sql) (query 20, line 22) (in query: select makeDate32(cast(1980 as Date32), 10, 30);), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: 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&&) @ 0x0000000012da74d9 4. /build/src/Functions/FunctionHelpers.cpp:130: DB::(anonymous namespace)::validateArgumentsImpl(DB::IFunction const&, std::vector> const&, unsigned long, std::vector> const&) @ 0x0000000012da5b15 5. /build/src/Functions/FunctionHelpers.cpp:192: DB::validateFunctionArguments(DB::IFunction const&, std::vector> const&, std::vector> const&, std::vector> const&) @ 0x0000000012da54fb 6. /build/src/Functions/makeDate.cpp:91: DB::(anonymous namespace)::FunctionMakeDate::getReturnTypeImpl(std::vector> const&) const @ 0x000000000cf7c834 7. /build/src/Functions/IFunction.cpp:645: DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x0000000012d96b0c 8. /build/src/Functions/IFunction.cpp:577: DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x0000000012d9669c 9. /build/src/Functions/IFunction.cpp:606: DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x0000000012d96edc 10. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3544: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000014033cc9 11. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3838: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000014019a9e 12. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3980: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000014018e31 13. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:4304: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000014042fa7 14. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5605: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000014013749 15. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000140127f9 16. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000014011fce 17. /build/src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000001406ce8a 18. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000014973b42 19. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000001497268d 20. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000014974d24 21. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001492924b 22. /build/src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88641 23. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 24. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 25. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 26. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 27. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 28. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 29. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 30. ? @ 0x00007fbc6213eac3 31. ? @ 0x00007fbc621d0850 2025.07.28 11:53:35.555003 [ 5879 ] {} TCPHandler: Code: 43. DB::Exception: A value of illegal type was provided as 1st argument 'year' to function 'makeDate32'. Expected: Number, got: Date32: In scope SELECT makeDate32(CAST(1980, 'Date32'), 10, 30). (ILLEGAL_TYPE_OF_ARGUMENT), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: 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&&) @ 0x0000000012da74d9 4. /build/src/Functions/FunctionHelpers.cpp:130: DB::(anonymous namespace)::validateArgumentsImpl(DB::IFunction const&, std::vector> const&, unsigned long, std::vector> const&) @ 0x0000000012da5b15 5. /build/src/Functions/FunctionHelpers.cpp:192: DB::validateFunctionArguments(DB::IFunction const&, std::vector> const&, std::vector> const&, std::vector> const&) @ 0x0000000012da54fb 6. /build/src/Functions/makeDate.cpp:91: DB::(anonymous namespace)::FunctionMakeDate::getReturnTypeImpl(std::vector> const&) const @ 0x000000000cf7c834 7. /build/src/Functions/IFunction.cpp:645: DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x0000000012d96b0c 8. /build/src/Functions/IFunction.cpp:577: DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x0000000012d9669c 9. /build/src/Functions/IFunction.cpp:606: DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x0000000012d96edc 10. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3544: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000014033cc9 11. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3838: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000014019a9e 12. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3980: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000014018e31 13. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:4304: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000014042fa7 14. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5605: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000014013749 15. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000140127f9 16. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000014011fce 17. /build/src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000001406ce8a 18. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000014973b42 19. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000001497268d 20. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000014974d24 21. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001492924b 22. /build/src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88641 23. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 24. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 25. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 26. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 27. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 28. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 29. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 30. ? @ 0x00007fbc6213eac3 31. ? @ 0x00007fbc621d0850 2025.07.28 11:53:35.585407 [ 5879 ] {38f4540d-54a4-4032-9384-33d3c1ea4594} executeQuery: Code: 43. DB::Exception: A value of illegal type was provided as 1st argument 'year' to function 'makeDate32'. Expected: Number, got: Date32: In scope SELECT makeDate32(CAST(-1980, 'Date32'), 10, 30). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.6.10636.altinitytest (altinity build)) (from [::1]:40084) (comment: 02243_make_date32.sql) (query 21, line 23) (in query: select makeDate32(cast(-1980 as Date32), 10, 30);), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: 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&&) @ 0x0000000012da74d9 4. /build/src/Functions/FunctionHelpers.cpp:130: DB::(anonymous namespace)::validateArgumentsImpl(DB::IFunction const&, std::vector> const&, unsigned long, std::vector> const&) @ 0x0000000012da5b15 5. /build/src/Functions/FunctionHelpers.cpp:192: DB::validateFunctionArguments(DB::IFunction const&, std::vector> const&, std::vector> const&, std::vector> const&) @ 0x0000000012da54fb 6. /build/src/Functions/makeDate.cpp:91: DB::(anonymous namespace)::FunctionMakeDate::getReturnTypeImpl(std::vector> const&) const @ 0x000000000cf7c834 7. /build/src/Functions/IFunction.cpp:645: DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x0000000012d96b0c 8. /build/src/Functions/IFunction.cpp:577: DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x0000000012d9669c 9. /build/src/Functions/IFunction.cpp:606: DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x0000000012d96edc 10. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3544: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000014033cc9 11. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3838: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000014019a9e 12. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3980: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000014018e31 13. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:4304: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000014042fa7 14. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5605: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000014013749 15. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000140127f9 16. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000014011fce 17. /build/src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000001406ce8a 18. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000014973b42 19. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000001497268d 20. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000014974d24 21. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001492924b 22. /build/src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88641 23. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 24. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 25. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 26. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 27. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 28. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 29. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 30. ? @ 0x00007fbc6213eac3 31. ? @ 0x00007fbc621d0850 2025.07.28 11:53:35.589429 [ 5879 ] {} TCPHandler: Code: 43. DB::Exception: A value of illegal type was provided as 1st argument 'year' to function 'makeDate32'. Expected: Number, got: Date32: In scope SELECT makeDate32(CAST(-1980, 'Date32'), 10, 30). (ILLEGAL_TYPE_OF_ARGUMENT), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: 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&&) @ 0x0000000012da74d9 4. /build/src/Functions/FunctionHelpers.cpp:130: DB::(anonymous namespace)::validateArgumentsImpl(DB::IFunction const&, std::vector> const&, unsigned long, std::vector> const&) @ 0x0000000012da5b15 5. /build/src/Functions/FunctionHelpers.cpp:192: DB::validateFunctionArguments(DB::IFunction const&, std::vector> const&, std::vector> const&, std::vector> const&) @ 0x0000000012da54fb 6. /build/src/Functions/makeDate.cpp:91: DB::(anonymous namespace)::FunctionMakeDate::getReturnTypeImpl(std::vector> const&) const @ 0x000000000cf7c834 7. /build/src/Functions/IFunction.cpp:645: DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x0000000012d96b0c 8. /build/src/Functions/IFunction.cpp:577: DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x0000000012d9669c 9. /build/src/Functions/IFunction.cpp:606: DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x0000000012d96edc 10. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3544: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000014033cc9 11. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3838: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000014019a9e 12. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3980: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000014018e31 13. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:4304: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000014042fa7 14. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5605: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000014013749 15. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000140127f9 16. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000014011fce 17. /build/src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000001406ce8a 18. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000014973b42 19. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000001497268d 20. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000014974d24 21. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001492924b 22. /build/src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88641 23. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 24. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 25. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 26. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 27. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 28. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 29. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 30. ? @ 0x00007fbc6213eac3 31. ? @ 0x00007fbc621d0850 2025.07.28 11:53:35.612336 [ 5879 ] {8176ccfa-c27d-429b-93e3-6a57e571abc0} executeQuery: Code: 43. DB::Exception: A value of illegal type was provided as 1st argument 'year' to function 'makeDate32'. Expected: Number, got: DateTime: In scope SELECT makeDate32(CAST(1980, 'DateTime'), 10, 30). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.6.10636.altinitytest (altinity build)) (from [::1]:40084) (comment: 02243_make_date32.sql) (query 22, line 24) (in query: select makeDate32(cast(1980 as DateTime), 10, 30);), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: 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&&) @ 0x0000000012da74d9 4. /build/src/Functions/FunctionHelpers.cpp:130: DB::(anonymous namespace)::validateArgumentsImpl(DB::IFunction const&, std::vector> const&, unsigned long, std::vector> const&) @ 0x0000000012da5b15 5. /build/src/Functions/FunctionHelpers.cpp:192: DB::validateFunctionArguments(DB::IFunction const&, std::vector> const&, std::vector> const&, std::vector> const&) @ 0x0000000012da54fb 6. /build/src/Functions/makeDate.cpp:91: DB::(anonymous namespace)::FunctionMakeDate::getReturnTypeImpl(std::vector> const&) const @ 0x000000000cf7c834 7. /build/src/Functions/IFunction.cpp:645: DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x0000000012d96b0c 8. /build/src/Functions/IFunction.cpp:577: DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x0000000012d9669c 9. /build/src/Functions/IFunction.cpp:606: DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x0000000012d96edc 10. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3544: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000014033cc9 11. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3838: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000014019a9e 12. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3980: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000014018e31 13. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:4304: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000014042fa7 14. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5605: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000014013749 15. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000140127f9 16. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000014011fce 17. /build/src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000001406ce8a 18. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000014973b42 19. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000001497268d 20. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000014974d24 21. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001492924b 22. /build/src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88641 23. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 24. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 25. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 26. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 27. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 28. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 29. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 30. ? @ 0x00007fbc6213eac3 31. ? @ 0x00007fbc621d0850 2025.07.28 11:53:35.617985 [ 5879 ] {} TCPHandler: Code: 43. DB::Exception: A value of illegal type was provided as 1st argument 'year' to function 'makeDate32'. Expected: Number, got: DateTime: In scope SELECT makeDate32(CAST(1980, 'DateTime'), 10, 30). (ILLEGAL_TYPE_OF_ARGUMENT), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: 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&&) @ 0x0000000012da74d9 4. /build/src/Functions/FunctionHelpers.cpp:130: DB::(anonymous namespace)::validateArgumentsImpl(DB::IFunction const&, std::vector> const&, unsigned long, std::vector> const&) @ 0x0000000012da5b15 5. /build/src/Functions/FunctionHelpers.cpp:192: DB::validateFunctionArguments(DB::IFunction const&, std::vector> const&, std::vector> const&, std::vector> const&) @ 0x0000000012da54fb 6. /build/src/Functions/makeDate.cpp:91: DB::(anonymous namespace)::FunctionMakeDate::getReturnTypeImpl(std::vector> const&) const @ 0x000000000cf7c834 7. /build/src/Functions/IFunction.cpp:645: DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x0000000012d96b0c 8. /build/src/Functions/IFunction.cpp:577: DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x0000000012d9669c 9. /build/src/Functions/IFunction.cpp:606: DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x0000000012d96edc 10. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3544: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000014033cc9 11. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3838: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000014019a9e 12. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3980: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000014018e31 13. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:4304: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000014042fa7 14. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5605: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000014013749 15. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000140127f9 16. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000014011fce 17. /build/src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000001406ce8a 18. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000014973b42 19. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000001497268d 20. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000014974d24 21. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001492924b 22. /build/src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88641 23. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 24. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 25. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 26. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 27. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 28. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 29. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 30. ? @ 0x00007fbc6213eac3 31. ? @ 0x00007fbc621d0850 2025.07.28 11:53:35.690168 [ 5879 ] {5154f125-96db-466a-aa85-7d632a6e0a16} executeQuery: Code: 43. DB::Exception: A value of illegal type was provided as 1st argument 'year' to function 'makeDate32'. Expected: Number, got: DateTime: In scope SELECT makeDate32(CAST(-1980, 'DateTime'), 10, 30). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.6.10636.altinitytest (altinity build)) (from [::1]:40084) (comment: 02243_make_date32.sql) (query 23, line 25) (in query: select makeDate32(cast(-1980 as DateTime), 10, 30);), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: 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&&) @ 0x0000000012da74d9 4. /build/src/Functions/FunctionHelpers.cpp:130: DB::(anonymous namespace)::validateArgumentsImpl(DB::IFunction const&, std::vector> const&, unsigned long, std::vector> const&) @ 0x0000000012da5b15 5. /build/src/Functions/FunctionHelpers.cpp:192: DB::validateFunctionArguments(DB::IFunction const&, std::vector> const&, std::vector> const&, std::vector> const&) @ 0x0000000012da54fb 6. /build/src/Functions/makeDate.cpp:91: DB::(anonymous namespace)::FunctionMakeDate::getReturnTypeImpl(std::vector> const&) const @ 0x000000000cf7c834 7. /build/src/Functions/IFunction.cpp:645: DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x0000000012d96b0c 8. /build/src/Functions/IFunction.cpp:577: DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x0000000012d9669c 9. /build/src/Functions/IFunction.cpp:606: DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x0000000012d96edc 10. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3544: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000014033cc9 11. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3838: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000014019a9e 12. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3980: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000014018e31 13. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:4304: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000014042fa7 14. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5605: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000014013749 15. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000140127f9 16. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000014011fce 17. /build/src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000001406ce8a 18. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000014973b42 19. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000001497268d 20. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000014974d24 21. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001492924b 22. /build/src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88641 23. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 24. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 25. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 26. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 27. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 28. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 29. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 30. ? @ 0x00007fbc6213eac3 31. ? @ 0x00007fbc621d0850 2025.07.28 11:53:35.692982 [ 5879 ] {} TCPHandler: Code: 43. DB::Exception: A value of illegal type was provided as 1st argument 'year' to function 'makeDate32'. Expected: Number, got: DateTime: In scope SELECT makeDate32(CAST(-1980, 'DateTime'), 10, 30). (ILLEGAL_TYPE_OF_ARGUMENT), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: 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&&) @ 0x0000000012da74d9 4. /build/src/Functions/FunctionHelpers.cpp:130: DB::(anonymous namespace)::validateArgumentsImpl(DB::IFunction const&, std::vector> const&, unsigned long, std::vector> const&) @ 0x0000000012da5b15 5. /build/src/Functions/FunctionHelpers.cpp:192: DB::validateFunctionArguments(DB::IFunction const&, std::vector> const&, std::vector> const&, std::vector> const&) @ 0x0000000012da54fb 6. /build/src/Functions/makeDate.cpp:91: DB::(anonymous namespace)::FunctionMakeDate::getReturnTypeImpl(std::vector> const&) const @ 0x000000000cf7c834 7. /build/src/Functions/IFunction.cpp:645: DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x0000000012d96b0c 8. /build/src/Functions/IFunction.cpp:577: DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x0000000012d9669c 9. /build/src/Functions/IFunction.cpp:606: DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x0000000012d96edc 10. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3544: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000014033cc9 11. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3838: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000014019a9e 12. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3980: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000014018e31 13. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:4304: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000014042fa7 14. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5605: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000014013749 15. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000140127f9 16. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000014011fce 17. /build/src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000001406ce8a 18. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000014973b42 19. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000001497268d 20. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000014974d24 21. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001492924b 22. /build/src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88641 23. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 24. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 25. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 26. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 27. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 28. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 29. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 30. ? @ 0x00007fbc6213eac3 31. ? @ 0x00007fbc621d0850 2025.07.28 11:53:35.715170 [ 5879 ] {45929017-e427-4911-a488-a1c02085ea55} executeQuery: Code: 43. DB::Exception: A value of illegal type was provided as 1st argument 'year' to function 'makeDate32'. Expected: Number, got: DateTime64(3): In scope SELECT makeDate32(CAST(1980, 'DateTime64'), 10, 30). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.6.10636.altinitytest (altinity build)) (from [::1]:40084) (comment: 02243_make_date32.sql) (query 24, line 26) (in query: select makeDate32(cast(1980 as DateTime64), 10, 30);), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: 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&&) @ 0x0000000012da74d9 4. /build/src/Functions/FunctionHelpers.cpp:130: DB::(anonymous namespace)::validateArgumentsImpl(DB::IFunction const&, std::vector> const&, unsigned long, std::vector> const&) @ 0x0000000012da5b15 5. /build/src/Functions/FunctionHelpers.cpp:192: DB::validateFunctionArguments(DB::IFunction const&, std::vector> const&, std::vector> const&, std::vector> const&) @ 0x0000000012da54fb 6. /build/src/Functions/makeDate.cpp:91: DB::(anonymous namespace)::FunctionMakeDate::getReturnTypeImpl(std::vector> const&) const @ 0x000000000cf7c834 7. /build/src/Functions/IFunction.cpp:645: DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x0000000012d96b0c 8. /build/src/Functions/IFunction.cpp:577: DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x0000000012d9669c 9. /build/src/Functions/IFunction.cpp:606: DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x0000000012d96edc 10. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3544: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000014033cc9 11. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3838: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000014019a9e 12. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3980: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000014018e31 13. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:4304: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000014042fa7 14. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5605: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000014013749 15. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000140127f9 16. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000014011fce 17. /build/src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000001406ce8a 18. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000014973b42 19. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000001497268d 20. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000014974d24 21. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001492924b 22. /build/src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88641 23. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 24. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 25. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 26. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 27. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 28. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 29. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 30. ? @ 0x00007fbc6213eac3 31. ? @ 0x00007fbc621d0850 2025.07.28 11:53:35.718454 [ 5879 ] {} TCPHandler: Code: 43. DB::Exception: A value of illegal type was provided as 1st argument 'year' to function 'makeDate32'. Expected: Number, got: DateTime64(3): In scope SELECT makeDate32(CAST(1980, 'DateTime64'), 10, 30). (ILLEGAL_TYPE_OF_ARGUMENT), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: 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&&) @ 0x0000000012da74d9 4. /build/src/Functions/FunctionHelpers.cpp:130: DB::(anonymous namespace)::validateArgumentsImpl(DB::IFunction const&, std::vector> const&, unsigned long, std::vector> const&) @ 0x0000000012da5b15 5. /build/src/Functions/FunctionHelpers.cpp:192: DB::validateFunctionArguments(DB::IFunction const&, std::vector> const&, std::vector> const&, std::vector> const&) @ 0x0000000012da54fb 6. /build/src/Functions/makeDate.cpp:91: DB::(anonymous namespace)::FunctionMakeDate::getReturnTypeImpl(std::vector> const&) const @ 0x000000000cf7c834 7. /build/src/Functions/IFunction.cpp:645: DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x0000000012d96b0c 8. /build/src/Functions/IFunction.cpp:577: DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x0000000012d9669c 9. /build/src/Functions/IFunction.cpp:606: DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x0000000012d96edc 10. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3544: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000014033cc9 11. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3838: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000014019a9e 12. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3980: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000014018e31 13. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:4304: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000014042fa7 14. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5605: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000014013749 15. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000140127f9 16. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000014011fce 17. /build/src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000001406ce8a 18. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000014973b42 19. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000001497268d 20. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000014974d24 21. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001492924b 22. /build/src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88641 23. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 24. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 25. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 26. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 27. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 28. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 29. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 30. ? @ 0x00007fbc6213eac3 31. ? @ 0x00007fbc621d0850 2025.07.28 11:53:35.747111 [ 3971 ] {} test_13.rmt2 (7f9b740d-015c-470e-8cc6-8ba33be0dc63): auto DB::StorageReplicatedMergeTree::processQueueEntry(ReplicatedMergeTreeQueue::SelectedEntryPtr)::(anonymous class)::operator()(LogEntryPtr &) const: Code: 86. DB::HTTPException: Received error from remote server http://146b4357c08d:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Ftest%2F01165%2Ftest_13%2Frmt%2Freplicas%2F1&part=20250728_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.6.10636.altinitytest (altinity build)) '. (RECEIVED_ERROR_FROM_REMOTE_IO_SERVER), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.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 const&, int&&, String const&, unsigned long&&, String const&) @ 0x000000000feda8d9 4. /build/src/IO/HTTPCommon.cpp:104: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x000000000feda6e2 5. /build/src/IO/HTTPCommon.cpp:93: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x000000000feda537 6. /build/src/IO/ReadWriteBufferFromHTTP.cpp:277: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x000000001184a4c4 7. /build/src/IO/ReadWriteBufferFromHTTP.cpp:285: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x000000001184a615 8. /build/src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x000000001184ae59 9. /build/src/IO/ReadWriteBufferFromHTTP.cpp:472: void std::__function::__policy_invoker::__call_impl[abi:se190107]>(std::__function::__policy_storage const*) @ 0x000000001184cedd 10. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001184858b 11. /build/src/IO/ReadWriteBufferFromHTTP.cpp:465: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x000000001184bf0b 12. /build/src/IO/ReadBuffer.h:60: DB::ReadBuffer::next() @ 0x000000000a148c7b 13. /build/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) @ 0x0000000011849fb2 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]>&)>&, 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&) @ 0x0000000011841980 15. /build/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) @ 0x000000001621208e 16. /build/src/Storages/StorageReplicatedMergeTree.cpp:5228: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl[abi:se190107] const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000015f9a5fe 17. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000015ed8bfd 18. /build/src/Storages/StorageReplicatedMergeTree.cpp:2514: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x0000000015ec9aab 19. /build/src/Storages/StorageReplicatedMergeTree.cpp:2349: DB::StorageReplicatedMergeTree::executeLogEntry(DB::ReplicatedMergeTreeLogEntry&) @ 0x0000000015eba91b 20. /build/src/Storages/StorageReplicatedMergeTree.cpp:3876: bool std::__function::__policy_invoker&)>::__call_impl[abi:se190107])::$_1, bool (std::shared_ptr&)>>(std::__function::__policy_storage const*, std::shared_ptr&) @ 0x0000000015f9837e 21. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000165d6fc3 22. /build/src/Storages/StorageReplicatedMergeTree.cpp:3872: DB::StorageReplicatedMergeTree::processQueueEntry(std::shared_ptr) @ 0x0000000015efc18a 23. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001624c1b2 24. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000162f9c70 25. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x00000000162fa55a 26. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc6653 27. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000000fccc4c3 28. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc3d92 29. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fcca080 30. ? @ 0x00007fbc6213eac3 31. ? @ 0x00007fbc621d0850 (version 25.3.6.10636.altinitytest (altinity build)) 2025.07.28 11:53:35.757898 [ 5879 ] {4a981956-eecb-4fe0-b285-bda6c40192b1} executeQuery: Code: 43. DB::Exception: A value of illegal type was provided as 1st argument 'year' to function 'makeDate32'. Expected: Number, got: DateTime64(3): In scope SELECT makeDate32(CAST(-1980, 'DateTime64'), 10, 30). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.6.10636.altinitytest (altinity build)) (from [::1]:40084) (comment: 02243_make_date32.sql) (query 25, line 27) (in query: select makeDate32(cast(-1980 as DateTime64), 10, 30);), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: 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&&) @ 0x0000000012da74d9 4. /build/src/Functions/FunctionHelpers.cpp:130: DB::(anonymous namespace)::validateArgumentsImpl(DB::IFunction const&, std::vector> const&, unsigned long, std::vector> const&) @ 0x0000000012da5b15 5. /build/src/Functions/FunctionHelpers.cpp:192: DB::validateFunctionArguments(DB::IFunction const&, std::vector> const&, std::vector> const&, std::vector> const&) @ 0x0000000012da54fb 6. /build/src/Functions/makeDate.cpp:91: DB::(anonymous namespace)::FunctionMakeDate::getReturnTypeImpl(std::vector> const&) const @ 0x000000000cf7c834 7. /build/src/Functions/IFunction.cpp:645: DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x0000000012d96b0c 8. /build/src/Functions/IFunction.cpp:577: DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x0000000012d9669c 9. /build/src/Functions/IFunction.cpp:606: DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x0000000012d96edc 10. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3544: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000014033cc9 11. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3838: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000014019a9e 12. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3980: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000014018e31 13. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:4304: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000014042fa7 14. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5605: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000014013749 15. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000140127f9 16. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000014011fce 17. /build/src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000001406ce8a 18. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000014973b42 19. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000001497268d 20. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000014974d24 21. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001492924b 22. /build/src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88641 23. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 24. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 25. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 26. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 27. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 28. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 29. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 30. ? @ 0x00007fbc6213eac3 31. ? @ 0x00007fbc621d0850 2025.07.28 11:53:35.762147 [ 5879 ] {} TCPHandler: Code: 43. DB::Exception: A value of illegal type was provided as 1st argument 'year' to function 'makeDate32'. Expected: Number, got: DateTime64(3): In scope SELECT makeDate32(CAST(-1980, 'DateTime64'), 10, 30). (ILLEGAL_TYPE_OF_ARGUMENT), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: 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&&) @ 0x0000000012da74d9 4. /build/src/Functions/FunctionHelpers.cpp:130: DB::(anonymous namespace)::validateArgumentsImpl(DB::IFunction const&, std::vector> const&, unsigned long, std::vector> const&) @ 0x0000000012da5b15 5. /build/src/Functions/FunctionHelpers.cpp:192: DB::validateFunctionArguments(DB::IFunction const&, std::vector> const&, std::vector> const&, std::vector> const&) @ 0x0000000012da54fb 6. /build/src/Functions/makeDate.cpp:91: DB::(anonymous namespace)::FunctionMakeDate::getReturnTypeImpl(std::vector> const&) const @ 0x000000000cf7c834 7. /build/src/Functions/IFunction.cpp:645: DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x0000000012d96b0c 8. /build/src/Functions/IFunction.cpp:577: DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x0000000012d9669c 9. /build/src/Functions/IFunction.cpp:606: DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x0000000012d96edc 10. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3544: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000014033cc9 11. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3838: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000014019a9e 12. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3980: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000014018e31 13. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:4304: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000014042fa7 14. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5605: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000014013749 15. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000140127f9 16. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000014011fce 17. /build/src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000001406ce8a 18. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000014973b42 19. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000001497268d 20. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000014974d24 21. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001492924b 22. /build/src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88641 23. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 24. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 25. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 26. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 27. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 28. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 29. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 30. ? @ 0x00007fbc6213eac3 31. ? @ 0x00007fbc621d0850 2025.07.28 11:53:36.548011 [ 3976 ] {} test_13.rmt2 (7f9b740d-015c-470e-8cc6-8ba33be0dc63): auto DB::StorageReplicatedMergeTree::processQueueEntry(ReplicatedMergeTreeQueue::SelectedEntryPtr)::(anonymous class)::operator()(LogEntryPtr &) const: Code: 86. DB::HTTPException: Received error from remote server http://146b4357c08d:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Ftest%2F01165%2Ftest_13%2Frmt%2Freplicas%2F1&part=20250728_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.6.10636.altinitytest (altinity build)) '. (RECEIVED_ERROR_FROM_REMOTE_IO_SERVER), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.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 const&, int&&, String const&, unsigned long&&, String const&) @ 0x000000000feda8d9 4. /build/src/IO/HTTPCommon.cpp:104: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x000000000feda6e2 5. /build/src/IO/HTTPCommon.cpp:93: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x000000000feda537 6. /build/src/IO/ReadWriteBufferFromHTTP.cpp:277: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x000000001184a4c4 7. /build/src/IO/ReadWriteBufferFromHTTP.cpp:285: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x000000001184a615 8. /build/src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x000000001184ae59 9. /build/src/IO/ReadWriteBufferFromHTTP.cpp:472: void std::__function::__policy_invoker::__call_impl[abi:se190107]>(std::__function::__policy_storage const*) @ 0x000000001184cedd 10. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001184858b 11. /build/src/IO/ReadWriteBufferFromHTTP.cpp:465: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x000000001184bf0b 12. /build/src/IO/ReadBuffer.h:60: DB::ReadBuffer::next() @ 0x000000000a148c7b 13. /build/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) @ 0x0000000011849fb2 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]>&)>&, 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&) @ 0x0000000011841980 15. /build/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) @ 0x000000001621208e 16. /build/src/Storages/StorageReplicatedMergeTree.cpp:5228: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl[abi:se190107] const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000015f9a5fe 17. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000015ed8bfd 18. /build/src/Storages/StorageReplicatedMergeTree.cpp:2514: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x0000000015ec9aab 19. /build/src/Storages/StorageReplicatedMergeTree.cpp:2349: DB::StorageReplicatedMergeTree::executeLogEntry(DB::ReplicatedMergeTreeLogEntry&) @ 0x0000000015eba91b 20. /build/src/Storages/StorageReplicatedMergeTree.cpp:3876: bool std::__function::__policy_invoker&)>::__call_impl[abi:se190107])::$_1, bool (std::shared_ptr&)>>(std::__function::__policy_storage const*, std::shared_ptr&) @ 0x0000000015f9837e 21. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000165d6fc3 22. /build/src/Storages/StorageReplicatedMergeTree.cpp:3872: DB::StorageReplicatedMergeTree::processQueueEntry(std::shared_ptr) @ 0x0000000015efc18a 23. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001624c1b2 24. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000162f9c70 25. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x00000000162fa55a 26. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc6653 27. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000000fccc4c3 28. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc3d92 29. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fcca080 30. ? @ 0x00007fbc6213eac3 31. ? @ 0x00007fbc621d0850 (version 25.3.6.10636.altinitytest (altinity build)) 2025.07.28 11:53:36.806036 [ 3962 ] {} test_13.rmt2 (7f9b740d-015c-470e-8cc6-8ba33be0dc63): auto DB::StorageReplicatedMergeTree::processQueueEntry(ReplicatedMergeTreeQueue::SelectedEntryPtr)::(anonymous class)::operator()(LogEntryPtr &) const: Code: 86. DB::HTTPException: Received error from remote server http://146b4357c08d:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Ftest%2F01165%2Ftest_13%2Frmt%2Freplicas%2F1&part=20250728_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.6.10636.altinitytest (altinity build)) '. (RECEIVED_ERROR_FROM_REMOTE_IO_SERVER), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.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 const&, int&&, String const&, unsigned long&&, String const&) @ 0x000000000feda8d9 4. /build/src/IO/HTTPCommon.cpp:104: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x000000000feda6e2 5. /build/src/IO/HTTPCommon.cpp:93: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x000000000feda537 6. /build/src/IO/ReadWriteBufferFromHTTP.cpp:277: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x000000001184a4c4 7. /build/src/IO/ReadWriteBufferFromHTTP.cpp:285: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x000000001184a615 8. /build/src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x000000001184ae59 9. /build/src/IO/ReadWriteBufferFromHTTP.cpp:472: void std::__function::__policy_invoker::__call_impl[abi:se190107]>(std::__function::__policy_storage const*) @ 0x000000001184cedd 10. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001184858b 11. /build/src/IO/ReadWriteBufferFromHTTP.cpp:465: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x000000001184bf0b 12. /build/src/IO/ReadBuffer.h:60: DB::ReadBuffer::next() @ 0x000000000a148c7b 13. /build/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) @ 0x0000000011849fb2 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]>&)>&, 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&) @ 0x0000000011841980 15. /build/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) @ 0x000000001621208e 16. /build/src/Storages/StorageReplicatedMergeTree.cpp:5228: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl[abi:se190107] const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000015f9a5fe 17. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000015ed8bfd 18. /build/src/Storages/StorageReplicatedMergeTree.cpp:2514: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x0000000015ec9aab 19. /build/src/Storages/StorageReplicatedMergeTree.cpp:2349: DB::StorageReplicatedMergeTree::executeLogEntry(DB::ReplicatedMergeTreeLogEntry&) @ 0x0000000015eba91b 20. /build/src/Storages/StorageReplicatedMergeTree.cpp:3876: bool std::__function::__policy_invoker&)>::__call_impl[abi:se190107])::$_1, bool (std::shared_ptr&)>>(std::__function::__policy_storage const*, std::shared_ptr&) @ 0x0000000015f9837e 21. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000165d6fc3 22. /build/src/Storages/StorageReplicatedMergeTree.cpp:3872: DB::StorageReplicatedMergeTree::processQueueEntry(std::shared_ptr) @ 0x0000000015efc18a 23. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001624c1b2 24. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000162f9c70 25. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x00000000162fa55a 26. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc6653 27. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000000fccc4c3 28. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc3d92 29. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fcca080 30. ? @ 0x00007fbc6213eac3 31. ? @ 0x00007fbc621d0850 (version 25.3.6.10636.altinitytest (altinity build)) 2025.07.28 11:53:37.916787 [ 3970 ] {} test_13.rmt2 (7f9b740d-015c-470e-8cc6-8ba33be0dc63): auto DB::StorageReplicatedMergeTree::processQueueEntry(ReplicatedMergeTreeQueue::SelectedEntryPtr)::(anonymous class)::operator()(LogEntryPtr &) const: Code: 86. DB::HTTPException: Received error from remote server http://146b4357c08d:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Ftest%2F01165%2Ftest_13%2Frmt%2Freplicas%2F1&part=20250728_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.6.10636.altinitytest (altinity build)) '. (RECEIVED_ERROR_FROM_REMOTE_IO_SERVER), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.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 const&, int&&, String const&, unsigned long&&, String const&) @ 0x000000000feda8d9 4. /build/src/IO/HTTPCommon.cpp:104: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x000000000feda6e2 5. /build/src/IO/HTTPCommon.cpp:93: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x000000000feda537 6. /build/src/IO/ReadWriteBufferFromHTTP.cpp:277: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x000000001184a4c4 7. /build/src/IO/ReadWriteBufferFromHTTP.cpp:285: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x000000001184a615 8. /build/src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x000000001184ae59 9. /build/src/IO/ReadWriteBufferFromHTTP.cpp:472: void std::__function::__policy_invoker::__call_impl[abi:se190107]>(std::__function::__policy_storage const*) @ 0x000000001184cedd 10. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001184858b 11. /build/src/IO/ReadWriteBufferFromHTTP.cpp:465: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x000000001184bf0b 12. /build/src/IO/ReadBuffer.h:60: DB::ReadBuffer::next() @ 0x000000000a148c7b 13. /build/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) @ 0x0000000011849fb2 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]>&)>&, 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&) @ 0x0000000011841980 15. /build/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) @ 0x000000001621208e 16. /build/src/Storages/StorageReplicatedMergeTree.cpp:5228: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl[abi:se190107] const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000015f9a5fe 17. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000015ed8bfd 18. /build/src/Storages/StorageReplicatedMergeTree.cpp:2514: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x0000000015ec9aab 19. /build/src/Storages/StorageReplicatedMergeTree.cpp:2349: DB::StorageReplicatedMergeTree::executeLogEntry(DB::ReplicatedMergeTreeLogEntry&) @ 0x0000000015eba91b 20. /build/src/Storages/StorageReplicatedMergeTree.cpp:3876: bool std::__function::__policy_invoker&)>::__call_impl[abi:se190107])::$_1, bool (std::shared_ptr&)>>(std::__function::__policy_storage const*, std::shared_ptr&) @ 0x0000000015f9837e 21. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000165d6fc3 22. /build/src/Storages/StorageReplicatedMergeTree.cpp:3872: DB::StorageReplicatedMergeTree::processQueueEntry(std::shared_ptr) @ 0x0000000015efc18a 23. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001624c1b2 24. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000162f9c70 25. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x00000000162fa55a 26. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc6653 27. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000000fccc4c3 28. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc3d92 29. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fcca080 30. ? @ 0x00007fbc6213eac3 31. ? @ 0x00007fbc621d0850 (version 25.3.6.10636.altinitytest (altinity build)) 2025.07.28 11:53:37.921115 [ 17261 ] {b5c8b5cc-00c6-498c-8586-82fd1623a8f8} 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.6.10636.altinitytest (altinity build)) (from [::1]:40068) (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. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000a06a8eb 4. /build/src/Functions/array/arrayAUC.cpp:161: DB::FunctionArrayAUC::getReturnTypeImpl(std::vector> const&) const @ 0x000000000ea7e9b3 5. /build/src/Functions/IFunction.cpp:645: DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x0000000012d96b0c 6. /build/src/Functions/IFunction.cpp:577: DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x0000000012d9669c 7. /build/src/Functions/IFunction.cpp:606: DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x0000000012d96edc 8. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3544: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000014033cc9 9. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3838: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000014019a9e 10. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3980: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000014018e31 11. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:4304: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000014042fa7 12. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5605: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000014013749 13. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000140127f9 14. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000014011fce 15. /build/src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000001406ce8a 16. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000014973b42 17. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000001497268d 18. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000014974d24 19. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001492924b 20. /build/src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88641 21. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 22. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 23. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 24. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 25. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 26. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 27. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 28. ? @ 0x00007fbc6213eac3 29. ? @ 0x00007fbc621d0850 2025.07.28 11:53:37.924688 [ 17261 ] {} 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. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000a06a8eb 4. /build/src/Functions/array/arrayAUC.cpp:161: DB::FunctionArrayAUC::getReturnTypeImpl(std::vector> const&) const @ 0x000000000ea7e9b3 5. /build/src/Functions/IFunction.cpp:645: DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x0000000012d96b0c 6. /build/src/Functions/IFunction.cpp:577: DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x0000000012d9669c 7. /build/src/Functions/IFunction.cpp:606: DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x0000000012d96edc 8. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3544: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000014033cc9 9. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3838: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000014019a9e 10. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3980: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000014018e31 11. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:4304: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000014042fa7 12. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5605: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000014013749 13. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000140127f9 14. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000014011fce 15. /build/src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000001406ce8a 16. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000014973b42 17. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000001497268d 18. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000014974d24 19. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001492924b 20. /build/src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88641 21. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 22. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 23. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 24. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 25. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 26. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 27. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 28. ? @ 0x00007fbc6213eac3 29. ? @ 0x00007fbc621d0850 2025.07.28 11:53:38.041826 [ 17261 ] {8948e8e6-f7a2-4d8c-a815-5cd03281f394} 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.6.10636.altinitytest (altinity build)) (from [::1]:40068) (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. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, unsigned long&, char const*&&) @ 0x000000000ea7cf6b 4. /build/src/Functions/array/arrayAUC.cpp:146: DB::FunctionArrayAUC::getReturnTypeImpl(std::vector> const&) const @ 0x000000000ea7e86a 5. /build/src/Functions/IFunction.cpp:645: DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x0000000012d96b0c 6. /build/src/Functions/IFunction.cpp:577: DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x0000000012d9669c 7. /build/src/Functions/IFunction.cpp:606: DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x0000000012d96edc 8. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3544: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000014033cc9 9. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3838: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000014019a9e 10. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3980: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000014018e31 11. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:4304: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000014042fa7 12. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5605: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000014013749 13. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000140127f9 14. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000014011fce 15. /build/src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000001406ce8a 16. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000014973b42 17. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000001497268d 18. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000014974d24 19. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001492924b 20. /build/src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88641 21. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 22. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 23. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 24. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 25. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 26. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 27. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 28. ? @ 0x00007fbc6213eac3 29. ? @ 0x00007fbc621d0850 2025.07.28 11:53:38.064504 [ 17261 ] {} 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. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, unsigned long&, char const*&&) @ 0x000000000ea7cf6b 4. /build/src/Functions/array/arrayAUC.cpp:146: DB::FunctionArrayAUC::getReturnTypeImpl(std::vector> const&) const @ 0x000000000ea7e86a 5. /build/src/Functions/IFunction.cpp:645: DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x0000000012d96b0c 6. /build/src/Functions/IFunction.cpp:577: DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x0000000012d9669c 7. /build/src/Functions/IFunction.cpp:606: DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x0000000012d96edc 8. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3544: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000014033cc9 9. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3838: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000014019a9e 10. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3980: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000014018e31 11. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:4304: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000014042fa7 12. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5605: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000014013749 13. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000140127f9 14. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000014011fce 15. /build/src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000001406ce8a 16. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000014973b42 17. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000001497268d 18. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000014974d24 19. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001492924b 20. /build/src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88641 21. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 22. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 23. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 24. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 25. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 26. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 27. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 28. ? @ 0x00007fbc6213eac3 29. ? @ 0x00007fbc621d0850 2025.07.28 11:53:38.172654 [ 17261 ] {ad79e485-667a-4631-bb86-aea366c1f4ee} 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.6.10636.altinitytest (altinity build)) (from [::1]:40068) (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. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x000000000a06b56b 4. /build/src/Functions/array/arrayAUC.cpp:237: DB::FunctionArrayAUC::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000ea7e1c9 5. /build/src/Functions/IFunction.h:437: DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000a069f2a 6. /build/src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000012d9965a 7. /build/src/Functions/IFunction.cpp:351: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d93b02 8. /build/src/Functions/IFunction.cpp:420: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d95059 9. /build/src/Functions/IFunction.cpp:498: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d95c72 10. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3567: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000014034494 11. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3838: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000014019a9e 12. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3980: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000014018e31 13. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:4304: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000014042fa7 14. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5605: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000014013749 15. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000140127f9 16. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000014011fce 17. /build/src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000001406ce8a 18. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000014973b42 19. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000001497268d 20. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000014974d24 21. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001492924b 22. /build/src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88641 23. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 24. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 25. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 26. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 27. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 28. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 29. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 30. ? @ 0x00007fbc6213eac3 31. ? @ 0x00007fbc621d0850 2025.07.28 11:53:38.185268 [ 17261 ] {} 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. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x000000000a06b56b 4. /build/src/Functions/array/arrayAUC.cpp:237: DB::FunctionArrayAUC::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000ea7e1c9 5. /build/src/Functions/IFunction.h:437: DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000a069f2a 6. /build/src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000012d9965a 7. /build/src/Functions/IFunction.cpp:351: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d93b02 8. /build/src/Functions/IFunction.cpp:420: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d95059 9. /build/src/Functions/IFunction.cpp:498: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d95c72 10. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3567: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000014034494 11. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3838: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000014019a9e 12. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3980: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000014018e31 13. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:4304: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000014042fa7 14. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5605: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000014013749 15. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000140127f9 16. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000014011fce 17. /build/src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000001406ce8a 18. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000014973b42 19. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000001497268d 20. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000014974d24 21. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001492924b 22. /build/src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88641 23. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 24. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 25. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 26. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 27. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 28. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 29. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 30. ? @ 0x00007fbc6213eac3 31. ? @ 0x00007fbc621d0850 2025.07.28 11:53:38.323900 [ 17261 ] {d5653d0c-3b49-4ec6-ba74-e9fbf13e8424} 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.6.10636.altinitytest (altinity build)) (from [::1]:40068) (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. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000a06a8eb 4. /build/src/Functions/array/arrayAUC.cpp:175: DB::FunctionArrayAUC::getReturnTypeImpl(std::vector> const&) const @ 0x000000000ea7eaf7 5. /build/src/Functions/IFunction.cpp:645: DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x0000000012d96b0c 6. /build/src/Functions/IFunction.cpp:577: DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x0000000012d9669c 7. /build/src/Functions/IFunction.cpp:606: DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x0000000012d96edc 8. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3544: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000014033cc9 9. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3838: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000014019a9e 10. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3980: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000014018e31 11. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:4304: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000014042fa7 12. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5605: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000014013749 13. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000140127f9 14. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000014011fce 15. /build/src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000001406ce8a 16. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000014973b42 17. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000001497268d 18. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000014974d24 19. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001492924b 20. /build/src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88641 21. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 22. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 23. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 24. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 25. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 26. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 27. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 28. ? @ 0x00007fbc6213eac3 29. ? @ 0x00007fbc621d0850 2025.07.28 11:53:38.340852 [ 17261 ] {} 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. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000a06a8eb 4. /build/src/Functions/array/arrayAUC.cpp:175: DB::FunctionArrayAUC::getReturnTypeImpl(std::vector> const&) const @ 0x000000000ea7eaf7 5. /build/src/Functions/IFunction.cpp:645: DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x0000000012d96b0c 6. /build/src/Functions/IFunction.cpp:577: DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x0000000012d9669c 7. /build/src/Functions/IFunction.cpp:606: DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x0000000012d96edc 8. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3544: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000014033cc9 9. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3838: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000014019a9e 10. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3980: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000014018e31 11. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:4304: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000014042fa7 12. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5605: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000014013749 13. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000140127f9 14. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000014011fce 15. /build/src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000001406ce8a 16. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000014973b42 17. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000001497268d 18. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000014974d24 19. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001492924b 20. /build/src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88641 21. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 22. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 23. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 24. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 25. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 26. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 27. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 28. ? @ 0x00007fbc6213eac3 29. ? @ 0x00007fbc621d0850 2025.07.28 11:53:38.370451 [ 17261 ] {6a99fb52-f4e5-408c-9646-c7726e53beb1} 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.6.10636.altinitytest (altinity build)) (from [::1]:40068) (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. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, unsigned long&, char const*&&) @ 0x000000000ea7cf6b 4. /build/src/Functions/array/arrayAUC.cpp:146: DB::FunctionArrayAUC::getReturnTypeImpl(std::vector> const&) const @ 0x000000000ea7e86a 5. /build/src/Functions/IFunction.cpp:645: DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x0000000012d96b0c 6. /build/src/Functions/IFunction.cpp:577: DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x0000000012d9669c 7. /build/src/Functions/IFunction.cpp:606: DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x0000000012d96edc 8. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3544: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000014033cc9 9. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3838: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000014019a9e 10. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3980: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000014018e31 11. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:4304: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000014042fa7 12. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5605: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000014013749 13. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000140127f9 14. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000014011fce 15. /build/src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000001406ce8a 16. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000014973b42 17. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000001497268d 18. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000014974d24 19. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001492924b 20. /build/src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88641 21. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 22. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 23. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 24. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 25. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 26. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 27. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 28. ? @ 0x00007fbc6213eac3 29. ? @ 0x00007fbc621d0850 2025.07.28 11:53:38.374124 [ 17261 ] {} 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. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, unsigned long&, char const*&&) @ 0x000000000ea7cf6b 4. /build/src/Functions/array/arrayAUC.cpp:146: DB::FunctionArrayAUC::getReturnTypeImpl(std::vector> const&) const @ 0x000000000ea7e86a 5. /build/src/Functions/IFunction.cpp:645: DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x0000000012d96b0c 6. /build/src/Functions/IFunction.cpp:577: DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x0000000012d9669c 7. /build/src/Functions/IFunction.cpp:606: DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x0000000012d96edc 8. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3544: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000014033cc9 9. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3838: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000014019a9e 10. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3980: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000014018e31 11. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:4304: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000014042fa7 12. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5605: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000014013749 13. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000140127f9 14. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000014011fce 15. /build/src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000001406ce8a 16. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000014973b42 17. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000001497268d 18. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000014974d24 19. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001492924b 20. /build/src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88641 21. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 22. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 23. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 24. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 25. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 26. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 27. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 28. ? @ 0x00007fbc6213eac3 29. ? @ 0x00007fbc621d0850 2025.07.28 11:53:38.415441 [ 17261 ] {9fa83986-32ae-4af9-8bd1-e9e02bd8bc83} 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.6.10636.altinitytest (altinity build)) (from [::1]:40068) (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. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000a06a8eb 4. /build/src/Functions/array/arrayAUC.cpp:161: DB::FunctionArrayAUC::getReturnTypeImpl(std::vector> const&) const @ 0x000000000ea7e9b3 5. /build/src/Functions/IFunction.cpp:645: DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x0000000012d96b0c 6. /build/src/Functions/IFunction.cpp:577: DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x0000000012d9669c 7. /build/src/Functions/IFunction.cpp:606: DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x0000000012d96edc 8. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3544: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000014033cc9 9. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3838: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000014019a9e 10. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3980: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000014018e31 11. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:4304: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000014042fa7 12. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5605: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000014013749 13. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000140127f9 14. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000014011fce 15. /build/src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000001406ce8a 16. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000014973b42 17. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000001497268d 18. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000014974d24 19. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001492924b 20. /build/src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88641 21. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 22. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 23. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 24. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 25. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 26. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 27. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 28. ? @ 0x00007fbc6213eac3 29. ? @ 0x00007fbc621d0850 2025.07.28 11:53:38.418303 [ 17261 ] {} 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. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000a06a8eb 4. /build/src/Functions/array/arrayAUC.cpp:161: DB::FunctionArrayAUC::getReturnTypeImpl(std::vector> const&) const @ 0x000000000ea7e9b3 5. /build/src/Functions/IFunction.cpp:645: DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x0000000012d96b0c 6. /build/src/Functions/IFunction.cpp:577: DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x0000000012d9669c 7. /build/src/Functions/IFunction.cpp:606: DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x0000000012d96edc 8. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3544: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000014033cc9 9. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3838: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000014019a9e 10. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3980: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000014018e31 11. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:4304: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000014042fa7 12. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5605: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000014013749 13. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000140127f9 14. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000014011fce 15. /build/src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000001406ce8a 16. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000014973b42 17. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000001497268d 18. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000014974d24 19. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001492924b 20. /build/src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88641 21. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 22. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 23. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 24. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 25. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 26. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 27. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 28. ? @ 0x00007fbc6213eac3 29. ? @ 0x00007fbc621d0850 2025.07.28 11:53:38.439210 [ 17261 ] {4260d614-fa4f-493c-bfb0-73ac5d44a29f} 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.6.10636.altinitytest (altinity build)) (from [::1]:40068) (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. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000a06a8eb 4. /build/src/Functions/array/arrayAUC.cpp:161: DB::FunctionArrayAUC::getReturnTypeImpl(std::vector> const&) const @ 0x000000000ea7e9b3 5. /build/src/Functions/IFunction.cpp:645: DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x0000000012d96b0c 6. /build/src/Functions/IFunction.cpp:577: DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x0000000012d9669c 7. /build/src/Functions/IFunction.cpp:606: DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x0000000012d96edc 8. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3544: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000014033cc9 9. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3838: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000014019a9e 10. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3980: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000014018e31 11. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:4304: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000014042fa7 12. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5605: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000014013749 13. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000140127f9 14. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000014011fce 15. /build/src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000001406ce8a 16. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000014973b42 17. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000001497268d 18. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000014974d24 19. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001492924b 20. /build/src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88641 21. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 22. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 23. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 24. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 25. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 26. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 27. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 28. ? @ 0x00007fbc6213eac3 29. ? @ 0x00007fbc621d0850 2025.07.28 11:53:38.467375 [ 17261 ] {} 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. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000a06a8eb 4. /build/src/Functions/array/arrayAUC.cpp:161: DB::FunctionArrayAUC::getReturnTypeImpl(std::vector> const&) const @ 0x000000000ea7e9b3 5. /build/src/Functions/IFunction.cpp:645: DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x0000000012d96b0c 6. /build/src/Functions/IFunction.cpp:577: DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x0000000012d9669c 7. /build/src/Functions/IFunction.cpp:606: DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x0000000012d96edc 8. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3544: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000014033cc9 9. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3838: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000014019a9e 10. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3980: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000014018e31 11. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:4304: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000014042fa7 12. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5605: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000014013749 13. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000140127f9 14. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000014011fce 15. /build/src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000001406ce8a 16. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000014973b42 17. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000001497268d 18. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000014974d24 19. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001492924b 20. /build/src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88641 21. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 22. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 23. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 24. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 25. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 26. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 27. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 28. ? @ 0x00007fbc6213eac3 29. ? @ 0x00007fbc621d0850 2025.07.28 11:53:38.510221 [ 17261 ] {5c47a3d3-45ca-4115-a992-5ce28b962086} 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.6.10636.altinitytest (altinity build)) (from [::1]:40068) (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. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000a06a8eb 4. /build/src/Functions/array/arrayAUC.cpp:175: DB::FunctionArrayAUC::getReturnTypeImpl(std::vector> const&) const @ 0x000000000ea7eaf7 5. /build/src/Functions/IFunction.cpp:645: DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x0000000012d96b0c 6. /build/src/Functions/IFunction.cpp:577: DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x0000000012d9669c 7. /build/src/Functions/IFunction.cpp:606: DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x0000000012d96edc 8. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3544: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000014033cc9 9. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3838: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000014019a9e 10. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3980: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000014018e31 11. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:4304: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000014042fa7 12. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5605: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000014013749 13. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000140127f9 14. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000014011fce 15. /build/src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000001406ce8a 16. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000014973b42 17. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000001497268d 18. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000014974d24 19. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001492924b 20. /build/src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88641 21. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 22. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 23. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 24. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 25. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 26. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 27. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 28. ? @ 0x00007fbc6213eac3 29. ? @ 0x00007fbc621d0850 2025.07.28 11:53:38.513445 [ 17261 ] {} 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. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000a06a8eb 4. /build/src/Functions/array/arrayAUC.cpp:175: DB::FunctionArrayAUC::getReturnTypeImpl(std::vector> const&) const @ 0x000000000ea7eaf7 5. /build/src/Functions/IFunction.cpp:645: DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x0000000012d96b0c 6. /build/src/Functions/IFunction.cpp:577: DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x0000000012d9669c 7. /build/src/Functions/IFunction.cpp:606: DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x0000000012d96edc 8. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3544: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000014033cc9 9. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3838: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000014019a9e 10. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3980: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000014018e31 11. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:4304: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000014042fa7 12. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5605: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000014013749 13. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000140127f9 14. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000014011fce 15. /build/src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000001406ce8a 16. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000014973b42 17. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000001497268d 18. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000014974d24 19. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001492924b 20. /build/src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88641 21. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 22. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 23. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 24. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 25. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 26. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 27. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 28. ? @ 0x00007fbc6213eac3 29. ? @ 0x00007fbc621d0850 2025.07.28 11:53:38.571438 [ 17261 ] {ad07cae8-6825-411e-924b-4109ee545f54} 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.6.10636.altinitytest (altinity build)) (from [::1]:40068) (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. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, char const*&&, String&&, String&&) @ 0x000000000ea7d14b 4. /build/src/Functions/array/arrayAUC.cpp:200: DB::FunctionArrayAUC::getReturnTypeImpl(std::vector> const&) const @ 0x000000000ea7ec4e 5. /build/src/Functions/IFunction.cpp:645: DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x0000000012d96b0c 6. /build/src/Functions/IFunction.cpp:577: DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x0000000012d9669c 7. /build/src/Functions/IFunction.cpp:606: DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x0000000012d96edc 8. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3544: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000014033cc9 9. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3838: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000014019a9e 10. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3980: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000014018e31 11. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:4304: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000014042fa7 12. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5605: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000014013749 13. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000140127f9 14. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000014011fce 15. /build/src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000001406ce8a 16. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000014973b42 17. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000001497268d 18. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000014974d24 19. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001492924b 20. /build/src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88641 21. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 22. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 23. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 24. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 25. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 26. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 27. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 28. ? @ 0x00007fbc6213eac3 29. ? @ 0x00007fbc621d0850 2025.07.28 11:53:38.631946 [ 17261 ] {} 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. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, char const*&&, String&&, String&&) @ 0x000000000ea7d14b 4. /build/src/Functions/array/arrayAUC.cpp:200: DB::FunctionArrayAUC::getReturnTypeImpl(std::vector> const&) const @ 0x000000000ea7ec4e 5. /build/src/Functions/IFunction.cpp:645: DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x0000000012d96b0c 6. /build/src/Functions/IFunction.cpp:577: DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x0000000012d9669c 7. /build/src/Functions/IFunction.cpp:606: DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x0000000012d96edc 8. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3544: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000014033cc9 9. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3838: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000014019a9e 10. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3980: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000014018e31 11. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:4304: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000014042fa7 12. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5605: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000014013749 13. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000140127f9 14. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000014011fce 15. /build/src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000001406ce8a 16. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000014973b42 17. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000001497268d 18. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000014974d24 19. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001492924b 20. /build/src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88641 21. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 22. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 23. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 24. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 25. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 26. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 27. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 28. ? @ 0x00007fbc6213eac3 29. ? @ 0x00007fbc621d0850 2025.07.28 11:53:38.699743 [ 17261 ] {a9d3c159-42dd-4340-baf7-6a70c0f6fbea} 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.6.10636.altinitytest (altinity build)) (from [::1]:40068) (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. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, char const*&&, String&&, String&&) @ 0x000000000ea7d14b 4. /build/src/Functions/array/arrayAUC.cpp:200: DB::FunctionArrayAUC::getReturnTypeImpl(std::vector> const&) const @ 0x000000000ea7ec4e 5. /build/src/Functions/IFunction.cpp:645: DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x0000000012d96b0c 6. /build/src/Functions/IFunction.cpp:577: DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x0000000012d9669c 7. /build/src/Functions/IFunction.cpp:606: DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x0000000012d96edc 8. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3544: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000014033cc9 9. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3838: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000014019a9e 10. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3980: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000014018e31 11. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:4304: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000014042fa7 12. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5605: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000014013749 13. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000140127f9 14. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000014011fce 15. /build/src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000001406ce8a 16. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000014973b42 17. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000001497268d 18. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000014974d24 19. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001492924b 20. /build/src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88641 21. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 22. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 23. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 24. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 25. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 26. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 27. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 28. ? @ 0x00007fbc6213eac3 29. ? @ 0x00007fbc621d0850 2025.07.28 11:53:38.711715 [ 17261 ] {} 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. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, char const*&&, String&&, String&&) @ 0x000000000ea7d14b 4. /build/src/Functions/array/arrayAUC.cpp:200: DB::FunctionArrayAUC::getReturnTypeImpl(std::vector> const&) const @ 0x000000000ea7ec4e 5. /build/src/Functions/IFunction.cpp:645: DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x0000000012d96b0c 6. /build/src/Functions/IFunction.cpp:577: DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x0000000012d9669c 7. /build/src/Functions/IFunction.cpp:606: DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x0000000012d96edc 8. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3544: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000014033cc9 9. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3838: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000014019a9e 10. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3980: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000014018e31 11. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:4304: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000014042fa7 12. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5605: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000014013749 13. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000140127f9 14. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000014011fce 15. /build/src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000001406ce8a 16. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000014973b42 17. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000001497268d 18. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000014974d24 19. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001492924b 20. /build/src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88641 21. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 22. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 23. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 24. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 25. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 26. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 27. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 28. ? @ 0x00007fbc6213eac3 29. ? @ 0x00007fbc621d0850 2025.07.28 11:53:38.749033 [ 12807 ] {ea4917d7-3b98-4e3b-9195-41c6e3d036da} 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:49638, 10000 ms): (127.0.0.2:9000, local address: 127.0.0.1:49638). (SOCKET_TIMEOUT) (version 25.3.6.10636.altinitytest (altinity build)) Code: 209. DB::NetException: Timeout exceeded while reading from socket (peer: 127.0.0.2:9000, local: 127.0.0.1:55604, 10000 ms): (127.0.0.2:9000, local address: 127.0.0.1:55604). (SOCKET_TIMEOUT) (version 25.3.6.10636.altinitytest (altinity build)) . (ALL_CONNECTION_TRIES_FAILED) (version 25.3.6.10636.altinitytest (altinity build)) . (NO_REMOTE_SHARD_AVAILABLE) (version 25.3.6.10636.altinitytest (altinity build)) (from [::1]:34600) (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. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::NetException::NetException(int, FormatStringHelperImpl::type>, String&) @ 0x0000000016056ce9 3. /build/src/Storages/getStructureOfRemoteTable.cpp:177: DB::getStructureOfRemoteTable(DB::Cluster const&, DB::StorageID const&, std::shared_ptr, std::shared_ptr const&) @ 0x00000000160552a4 4. /build/src/TableFunctions/TableFunctionRemote.cpp:337: DB::TableFunctionRemote::getActualTableStructure(std::shared_ptr, bool) const @ 0x0000000011805ecb 5. /build/src/TableFunctions/TableFunctionRemote.cpp:309: DB::TableFunctionRemote::executeImpl(std::shared_ptr const&, std::shared_ptr, String const&, DB::ColumnsDescription, bool) const @ 0x00000000118056e0 6. /build/src/TableFunctions/ITableFunction.cpp:36: DB::ITableFunction::execute(std::shared_ptr const&, std::shared_ptr, String const&, DB::ColumnsDescription, bool, bool) const @ 0x00000000131e9fc3 7. /build/src/Interpreters/Context.cpp:2501: DB::Context::executeTableFunction(std::shared_ptr const&, std::shared_ptr const&) @ 0x00000000144345b2 8. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:4975: DB::QueryAnalyzer::resolveTableFunction(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&, bool) @ 0x000000001401e9f9 9. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5342: DB::QueryAnalyzer::resolveQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&) @ 0x00000000140452bf 10. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5597: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000140136f0 11. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000140127f9 12. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000014011fce 13. /build/src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000001406ce8a 14. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000014973b42 15. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000001497268d 16. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000014974d24 17. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001492924b 18. /build/src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88641 19. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 20. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 21. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 22. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 23. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 24. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 25. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 26. ? @ 0x00007fbc6213eac3 27. ? @ 0x00007fbc621d0850 2025.07.28 11:53:38.752497 [ 12807 ] {} 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:49638, 10000 ms): (127.0.0.2:9000, local address: 127.0.0.1:49638). (SOCKET_TIMEOUT) (version 25.3.6.10636.altinitytest (altinity build)) Code: 209. DB::NetException: Timeout exceeded while reading from socket (peer: 127.0.0.2:9000, local: 127.0.0.1:55604, 10000 ms): (127.0.0.2:9000, local address: 127.0.0.1:55604). (SOCKET_TIMEOUT) (version 25.3.6.10636.altinitytest (altinity build)) . (ALL_CONNECTION_TRIES_FAILED) (version 25.3.6.10636.altinitytest (altinity build)) . (NO_REMOTE_SHARD_AVAILABLE), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::NetException::NetException(int, FormatStringHelperImpl::type>, String&) @ 0x0000000016056ce9 3. /build/src/Storages/getStructureOfRemoteTable.cpp:177: DB::getStructureOfRemoteTable(DB::Cluster const&, DB::StorageID const&, std::shared_ptr, std::shared_ptr const&) @ 0x00000000160552a4 4. /build/src/TableFunctions/TableFunctionRemote.cpp:337: DB::TableFunctionRemote::getActualTableStructure(std::shared_ptr, bool) const @ 0x0000000011805ecb 5. /build/src/TableFunctions/TableFunctionRemote.cpp:309: DB::TableFunctionRemote::executeImpl(std::shared_ptr const&, std::shared_ptr, String const&, DB::ColumnsDescription, bool) const @ 0x00000000118056e0 6. /build/src/TableFunctions/ITableFunction.cpp:36: DB::ITableFunction::execute(std::shared_ptr const&, std::shared_ptr, String const&, DB::ColumnsDescription, bool, bool) const @ 0x00000000131e9fc3 7. /build/src/Interpreters/Context.cpp:2501: DB::Context::executeTableFunction(std::shared_ptr const&, std::shared_ptr const&) @ 0x00000000144345b2 8. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:4975: DB::QueryAnalyzer::resolveTableFunction(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&, bool) @ 0x000000001401e9f9 9. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5342: DB::QueryAnalyzer::resolveQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&) @ 0x00000000140452bf 10. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5597: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000140136f0 11. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000140127f9 12. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000014011fce 13. /build/src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000001406ce8a 14. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000014973b42 15. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000001497268d 16. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000014974d24 17. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001492924b 18. /build/src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88641 19. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 20. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 21. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 22. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 23. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 24. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 25. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 26. ? @ 0x00007fbc6213eac3 27. ? @ 0x00007fbc621d0850 2025.07.28 11:53:38.788018 [ 17261 ] {11ca4515-d90f-4de3-b96b-4b5fc8b24e25} 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.6.10636.altinitytest (altinity build)) (from [::1]:40068) (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. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, char const*&&, String&&, unsigned long const&) @ 0x000000000ea7a24b 4. /build/src/Functions/array/arrayAUC.cpp:263: DB::FunctionArrayAUC::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000ea7e29b 5. /build/src/Functions/IFunction.h:437: DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000a069f2a 6. /build/src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000012d9965a 7. /build/src/Functions/IFunction.cpp:351: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d93b02 8. /build/src/Functions/IFunction.cpp:420: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d95059 9. /build/src/Functions/IFunction.cpp:498: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d95c72 10. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3567: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000014034494 11. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3838: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000014019a9e 12. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3980: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000014018e31 13. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:4304: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000014042fa7 14. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5605: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000014013749 15. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000140127f9 16. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000014011fce 17. /build/src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000001406ce8a 18. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000014973b42 19. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000001497268d 20. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000014974d24 21. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001492924b 22. /build/src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88641 23. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 24. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 25. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 26. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 27. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 28. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 29. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 30. ? @ 0x00007fbc6213eac3 31. ? @ 0x00007fbc621d0850 2025.07.28 11:53:38.810902 [ 17261 ] {} 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. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, char const*&&, String&&, unsigned long const&) @ 0x000000000ea7a24b 4. /build/src/Functions/array/arrayAUC.cpp:263: DB::FunctionArrayAUC::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000ea7e29b 5. /build/src/Functions/IFunction.h:437: DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000a069f2a 6. /build/src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000012d9965a 7. /build/src/Functions/IFunction.cpp:351: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d93b02 8. /build/src/Functions/IFunction.cpp:420: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d95059 9. /build/src/Functions/IFunction.cpp:498: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d95c72 10. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3567: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000014034494 11. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3838: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000014019a9e 12. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3980: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000014018e31 13. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:4304: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000014042fa7 14. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5605: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000014013749 15. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000140127f9 16. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000014011fce 17. /build/src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000001406ce8a 18. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000014973b42 19. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000001497268d 20. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000014974d24 21. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001492924b 22. /build/src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88641 23. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 24. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 25. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 26. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 27. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 28. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 29. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 30. ? @ 0x00007fbc6213eac3 31. ? @ 0x00007fbc621d0850 2025.07.28 11:53:38.928629 [ 17261 ] {b90ef8a6-1869-4409-9e30-bb4034a52d01} 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.6.10636.altinitytest (altinity build)) (from [::1]:40068) (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. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, char const*&&, String&&) @ 0x000000000ea7a40b 4. /build/src/Functions/array/arrayAUC.cpp:287: DB::FunctionArrayAUC::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000ea7decd 5. /build/src/Functions/IFunction.h:437: DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000a069f2a 6. /build/src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000012d9965a 7. /build/src/Functions/IFunction.cpp:351: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d93b02 8. /build/src/Functions/IFunction.cpp:420: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d95059 9. /build/src/Functions/IFunction.cpp:498: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d95c72 10. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3567: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000014034494 11. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3838: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000014019a9e 12. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3980: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000014018e31 13. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:4304: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000014042fa7 14. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5605: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000014013749 15. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000140127f9 16. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000014011fce 17. /build/src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000001406ce8a 18. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000014973b42 19. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000001497268d 20. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000014974d24 21. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001492924b 22. /build/src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88641 23. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 24. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 25. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 26. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 27. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 28. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 29. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 30. ? @ 0x00007fbc6213eac3 31. ? @ 0x00007fbc621d0850 2025.07.28 11:53:38.932840 [ 17210 ] {} 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. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Access/AccessControl.cpp:646: DB::AccessControl::authenticate(DB::Credentials const&, Poco::Net::IPAddress const&, DB::ClientInfo const&) const @ 0x0000000013727552 4. /build/src/Interpreters/Session.cpp:371: DB::Session::authenticate(DB::Credentials const&, Poco::Net::SocketAddress const&, std::vector> const&) @ 0x0000000014a6dd4d 5. /build/src/Interpreters/Session.cpp:350: DB::Session::authenticate(String const&, String const&, Poco::Net::SocketAddress const&, std::vector> const&) @ 0x0000000014a6d7b0 6. /build/src/Server/TCPHandler.cpp:1798: DB::TCPHandler::receiveHello() @ 0x00000000168ed801 7. /build/src/Server/TCPHandler.cpp:339: DB::TCPHandler::runImpl() @ 0x00000000168e59e6 8. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 9. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 10. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 11. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 12. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 13. ? @ 0x00007fbc6213eac3 14. ? @ 0x00007fbc621d0850 (version 25.3.6.10636.altinitytest (altinity build)) 2025.07.28 11:53:38.934150 [ 17210 ] {} 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. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Access/AccessControl.cpp:646: DB::AccessControl::authenticate(DB::Credentials const&, Poco::Net::IPAddress const&, DB::ClientInfo const&) const @ 0x0000000013727552 4. /build/src/Interpreters/Session.cpp:371: DB::Session::authenticate(DB::Credentials const&, Poco::Net::SocketAddress const&, std::vector> const&) @ 0x0000000014a6dd4d 5. /build/src/Interpreters/Session.cpp:350: DB::Session::authenticate(String const&, String const&, Poco::Net::SocketAddress const&, std::vector> const&) @ 0x0000000014a6d7b0 6. /build/src/Server/TCPHandler.cpp:1798: DB::TCPHandler::receiveHello() @ 0x00000000168ed801 7. /build/src/Server/TCPHandler.cpp:339: DB::TCPHandler::runImpl() @ 0x00000000168e59e6 8. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 9. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 10. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 11. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 12. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 13. ? @ 0x00007fbc6213eac3 14. ? @ 0x00007fbc621d0850 (version 25.3.6.10636.altinitytest (altinity build)) 2025.07.28 11:53:38.935415 [ 17261 ] {} 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. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, char const*&&, String&&) @ 0x000000000ea7a40b 4. /build/src/Functions/array/arrayAUC.cpp:287: DB::FunctionArrayAUC::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000ea7decd 5. /build/src/Functions/IFunction.h:437: DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000a069f2a 6. /build/src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000012d9965a 7. /build/src/Functions/IFunction.cpp:351: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d93b02 8. /build/src/Functions/IFunction.cpp:420: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d95059 9. /build/src/Functions/IFunction.cpp:498: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d95c72 10. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3567: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000014034494 11. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3838: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000014019a9e 12. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3980: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000014018e31 13. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:4304: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000014042fa7 14. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5605: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000014013749 15. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000140127f9 16. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000014011fce 17. /build/src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000001406ce8a 18. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000014973b42 19. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000001497268d 20. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000014974d24 21. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001492924b 22. /build/src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88641 23. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 24. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 25. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 26. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 27. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 28. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 29. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 30. ? @ 0x00007fbc6213eac3 31. ? @ 0x00007fbc621d0850 2025.07.28 11:53:38.939421 [ 12807 ] {36f10ce6-96bb-4625-90e5-dd2106d77143} 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. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Access/AccessControl.cpp:646: DB::AccessControl::authenticate(DB::Credentials const&, Poco::Net::IPAddress const&, DB::ClientInfo const&) const @ 0x0000000013727552 4. /build/src/Interpreters/Session.cpp:371: DB::Session::authenticate(DB::Credentials const&, Poco::Net::SocketAddress const&, std::vector> const&) @ 0x0000000014a6dd4d 5. /build/src/Interpreters/Session.cpp:350: DB::Session::authenticate(String const&, String const&, Poco::Net::SocketAddress const&, std::vector> const&) @ 0x0000000014a6d7b0 6. /build/src/Server/TCPHandler.cpp:1798: DB::TCPHandler::receiveHello() @ 0x00000000168ed801 7. /build/src/Server/TCPHandler.cpp:339: DB::TCPHandler::runImpl() @ 0x00000000168e59e6 8. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 9. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 10. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 11. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 12. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 13. ? @ 0x00007fbc6213eac3 14. ? @ 0x00007fbc621d0850 . (AUTHENTICATION_FAILED) (version 25.3.6.10636.altinitytest (altinity build)) (from [::1]:34600) (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. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:111: DB::readException(DB::ReadBuffer&, String const&, bool) @ 0x000000000fc6e157 3. /build/src/Client/Connection.cpp:1445: DB::Connection::receiveException() const @ 0x00000000167d4127 4. /build/src/Client/Connection.cpp:577: DB::Connection::receiveHello(Poco::Timespan const&) @ 0x00000000167d27a3 5. /build/src/Client/Connection.cpp:235: DB::Connection::connect(DB::ConnectionTimeouts const&) @ 0x00000000167d0891 6. /build/src/Client/Connection.cpp:635: DB::Connection::getServerRevision(DB::ConnectionTimeouts const&) @ 0x00000000167d46b5 7. /build/src/Client/ConnectionEstablisher.cpp:56: DB::ConnectionEstablisher::run(PoolWithFailoverBase::TryResult&, String&, bool) @ 0x00000000167e5d4b 8. /build/src/Client/ConnectionEstablisher.cpp:154: DB::ConnectionEstablisherAsync::Task::run(std::function, std::function) @ 0x00000000167e7751 9. /build/src/Common/AsyncTaskExecutor.cpp:89: DB::AsyncTaskExecutor::Routine::operator()(std::function) @ 0x0000000013bd1892 10. /build/src/Common/Fiber.h:76: boost::context::detail::fiber_record>::run(void*) @ 0x0000000013bd16fa 11. /build/contrib/boost/boost/context/fiber_fcontext.hpp:97: void boost::context::detail::fiber_entry>>(boost::context::detail::transfer_t) @ 0x0000000013bd1621 2025.07.28 11:53:39.006065 [ 12807 ] {} 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. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Access/AccessControl.cpp:646: DB::AccessControl::authenticate(DB::Credentials const&, Poco::Net::IPAddress const&, DB::ClientInfo const&) const @ 0x0000000013727552 4. /build/src/Interpreters/Session.cpp:371: DB::Session::authenticate(DB::Credentials const&, Poco::Net::SocketAddress const&, std::vector> const&) @ 0x0000000014a6dd4d 5. /build/src/Interpreters/Session.cpp:350: DB::Session::authenticate(String const&, String const&, Poco::Net::SocketAddress const&, std::vector> const&) @ 0x0000000014a6d7b0 6. /build/src/Server/TCPHandler.cpp:1798: DB::TCPHandler::receiveHello() @ 0x00000000168ed801 7. /build/src/Server/TCPHandler.cpp:339: DB::TCPHandler::runImpl() @ 0x00000000168e59e6 8. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 9. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 10. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 11. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 12. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 13. ? @ 0x00007fbc6213eac3 14. ? @ 0x00007fbc621d0850 . (AUTHENTICATION_FAILED), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:111: DB::readException(DB::ReadBuffer&, String const&, bool) @ 0x000000000fc6e157 3. /build/src/Client/Connection.cpp:1445: DB::Connection::receiveException() const @ 0x00000000167d4127 4. /build/src/Client/Connection.cpp:577: DB::Connection::receiveHello(Poco::Timespan const&) @ 0x00000000167d27a3 5. /build/src/Client/Connection.cpp:235: DB::Connection::connect(DB::ConnectionTimeouts const&) @ 0x00000000167d0891 6. /build/src/Client/Connection.cpp:635: DB::Connection::getServerRevision(DB::ConnectionTimeouts const&) @ 0x00000000167d46b5 7. /build/src/Client/ConnectionEstablisher.cpp:56: DB::ConnectionEstablisher::run(PoolWithFailoverBase::TryResult&, String&, bool) @ 0x00000000167e5d4b 8. /build/src/Client/ConnectionEstablisher.cpp:154: DB::ConnectionEstablisherAsync::Task::run(std::function, std::function) @ 0x00000000167e7751 9. /build/src/Common/AsyncTaskExecutor.cpp:89: DB::AsyncTaskExecutor::Routine::operator()(std::function) @ 0x0000000013bd1892 10. /build/src/Common/Fiber.h:76: boost::context::detail::fiber_record>::run(void*) @ 0x0000000013bd16fa 11. /build/contrib/boost/boost/context/fiber_fcontext.hpp:97: void boost::context::detail::fiber_entry>>(boost::context::detail::transfer_t) @ 0x0000000013bd1621 2025.07.28 11:53:39.020574 [ 3964 ] {} test_13.rmt2 (7f9b740d-015c-470e-8cc6-8ba33be0dc63): auto DB::StorageReplicatedMergeTree::processQueueEntry(ReplicatedMergeTreeQueue::SelectedEntryPtr)::(anonymous class)::operator()(LogEntryPtr &) const: Code: 86. DB::HTTPException: Received error from remote server http://146b4357c08d:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Ftest%2F01165%2Ftest_13%2Frmt%2Freplicas%2F1&part=20250728_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.6.10636.altinitytest (altinity build)) '. (RECEIVED_ERROR_FROM_REMOTE_IO_SERVER), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.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 const&, int&&, String const&, unsigned long&&, String const&) @ 0x000000000feda8d9 4. /build/src/IO/HTTPCommon.cpp:104: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x000000000feda6e2 5. /build/src/IO/HTTPCommon.cpp:93: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x000000000feda537 6. /build/src/IO/ReadWriteBufferFromHTTP.cpp:277: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x000000001184a4c4 7. /build/src/IO/ReadWriteBufferFromHTTP.cpp:285: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x000000001184a615 8. /build/src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x000000001184ae59 9. /build/src/IO/ReadWriteBufferFromHTTP.cpp:472: void std::__function::__policy_invoker::__call_impl[abi:se190107]>(std::__function::__policy_storage const*) @ 0x000000001184cedd 10. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001184858b 11. /build/src/IO/ReadWriteBufferFromHTTP.cpp:465: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x000000001184bf0b 12. /build/src/IO/ReadBuffer.h:60: DB::ReadBuffer::next() @ 0x000000000a148c7b 13. /build/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) @ 0x0000000011849fb2 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]>&)>&, 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&) @ 0x0000000011841980 15. /build/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) @ 0x000000001621208e 16. /build/src/Storages/StorageReplicatedMergeTree.cpp:5228: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl[abi:se190107] const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000015f9a5fe 17. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000015ed8bfd 18. /build/src/Storages/StorageReplicatedMergeTree.cpp:2514: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x0000000015ec9aab 19. /build/src/Storages/StorageReplicatedMergeTree.cpp:2349: DB::StorageReplicatedMergeTree::executeLogEntry(DB::ReplicatedMergeTreeLogEntry&) @ 0x0000000015eba91b 20. /build/src/Storages/StorageReplicatedMergeTree.cpp:3876: bool std::__function::__policy_invoker&)>::__call_impl[abi:se190107])::$_1, bool (std::shared_ptr&)>>(std::__function::__policy_storage const*, std::shared_ptr&) @ 0x0000000015f9837e 21. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000165d6fc3 22. /build/src/Storages/StorageReplicatedMergeTree.cpp:3872: DB::StorageReplicatedMergeTree::processQueueEntry(std::shared_ptr) @ 0x0000000015efc18a 23. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001624c1b2 24. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000162f9c70 25. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x00000000162fa55a 26. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc6653 27. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000000fccc4c3 28. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc3d92 29. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fcca080 30. ? @ 0x00007fbc6213eac3 31. ? @ 0x00007fbc621d0850 (version 25.3.6.10636.altinitytest (altinity build)) 2025.07.28 11:53:39.181310 [ 17203 ] {} 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. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception>&, String>(int, FormatStringHelperImpl>&>::type, std::type_identity::type>, std::basic_string_view>&, String&&) @ 0x000000001385a5eb 4. /build/src/Access/SettingsConstraints.cpp:376: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000013859b18 5. /build/src/Access/SettingsConstraints.cpp:300: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000013858faf 6. /build/src/Access/SettingsConstraints.cpp:209: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000013859223 7. /build/src/Interpreters/Context.cpp:2690: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000014436134 8. /build/src/Interpreters/Context.cpp:2729: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x000000001443662b 9. /build/src/Server/HTTPHandler.cpp:457: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000001686d165 10. /build/src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x0000000016870807 11. /build/src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x0000000016907e99 12. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 13. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 14. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 15. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 16. ? @ 0x00007fbc6213eac3 17. ? @ 0x00007fbc621d0850 (version 25.3.6.10636.altinitytest (altinity build)) 2025.07.28 11:53:39.202299 [ 17261 ] {9f0af35b-b2f8-4bb9-afb6-6c42e7f05bdb} 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.6.10636.altinitytest (altinity build)) (from [::1]:40068) (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. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, char const*&&, String&&, unsigned long const&) @ 0x000000000ea7a24b 4. /build/src/Functions/array/arrayAUC.cpp:263: DB::FunctionArrayAUC::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000ea7e29b 5. /build/src/Functions/IFunctionAdaptors.cpp:10: DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000012d995fa 6. /build/src/Functions/IFunction.cpp:353: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d93b52 7. /build/src/Functions/IFunction.cpp:420: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d95059 8. /build/src/Functions/IFunction.cpp:498: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d95c72 9. /build/src/Interpreters/ExpressionActions.cpp:636: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x00000000145176f3 10. /build/src/Processors/Transforms/ExpressionTransform.cpp:25: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x0000000016c0b34c 11. /build/src/Processors/ISimpleTransform.h:33: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000011a9a453 12. /build/src/Processors/ISimpleTransform.cpp:89: DB::ISimpleTransform::work() @ 0x000000001699fca0 13. /build/src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x00000000169bd00f 14. /build/src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x00000000169b2105 15. /build/src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeSingleThread(unsigned long) @ 0x00000000169b23be 16. /build/src/Processors/Executors/PipelineExecutor.cpp:416: void std::__function::__policy_invoker::__call_impl[abi:se190107]>(std::__function::__policy_storage const*) @ 0x00000000169b2e3f 17. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc6653 18. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000000fccc4c3 19. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc3d92 20. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fcca080 21. ? @ 0x00007fbc6213eac3 22. ? @ 0x00007fbc621d0850 2025.07.28 11:53:39.226290 [ 17261 ] {} 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. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, char const*&&, String&&, unsigned long const&) @ 0x000000000ea7a24b 4. /build/src/Functions/array/arrayAUC.cpp:263: DB::FunctionArrayAUC::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000ea7e29b 5. /build/src/Functions/IFunctionAdaptors.cpp:10: DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000012d995fa 6. /build/src/Functions/IFunction.cpp:353: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d93b52 7. /build/src/Functions/IFunction.cpp:420: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d95059 8. /build/src/Functions/IFunction.cpp:498: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d95c72 9. /build/src/Interpreters/ExpressionActions.cpp:636: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x00000000145176f3 10. /build/src/Processors/Transforms/ExpressionTransform.cpp:25: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x0000000016c0b34c 11. /build/src/Processors/ISimpleTransform.h:33: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000011a9a453 12. /build/src/Processors/ISimpleTransform.cpp:89: DB::ISimpleTransform::work() @ 0x000000001699fca0 13. /build/src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x00000000169bd00f 14. /build/src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x00000000169b2105 15. /build/src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeSingleThread(unsigned long) @ 0x00000000169b23be 16. /build/src/Processors/Executors/PipelineExecutor.cpp:416: void std::__function::__policy_invoker::__call_impl[abi:se190107]>(std::__function::__policy_storage const*) @ 0x00000000169b2e3f 17. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc6653 18. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000000fccc4c3 19. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc3d92 20. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fcca080 21. ? @ 0x00007fbc6213eac3 22. ? @ 0x00007fbc621d0850 Job's origin stack trace: 0. /build/src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000000fc33b84 1. /build/src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000000fcc2ea7 2. /build/src/Common/ThreadPool.cpp:401: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fcc7f1c 3. /build/src/Common/ThreadPool.cpp:494: ThreadPoolImpl>::scheduleOrThrowOnError(std::function, Priority) @ 0x000000000fcc7a0e 4. /build/src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::spawnThreadsImpl() @ 0x00000000169b2c0c 5. /build/src/Processors/Executors/PipelineExecutor.cpp:394: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x00000000169b0ba7 6. /build/src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x00000000169b03f4 7. /build/src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:se190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169bfeab 8. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc3d92 9. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fcca080 10. ? @ 0x00007fbc6213eac3 11. ? @ 0x00007fbc621d0850 Job's origin stack trace: 0. /build/src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000000fc33b84 1. /build/src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000000fcc2ea7 2. /build/src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fcc535c 3. /build/src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000000fcc584d 4. /build/src/Common/ThreadPool.h:279: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x00000000169bf193 5. /build/src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x00000000169bf518 6. /build/src/Server/TCPHandler.cpp:1237: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x00000000168f1525 7. /build/src/Server/TCPHandler.cpp:678: DB::TCPHandler::runImpl() @ 0x00000000168e68e5 8. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 9. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 10. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 11. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 12. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 13. ? @ 0x00007fbc6213eac3 14. ? @ 0x00007fbc621d0850 2025.07.28 11:53:39.339658 [ 4580 ] {5db3b117-fb84-487b-846d-708d1ce51fee} executeQuery: Code: 16. DB::Exception: No such column arr_v2 in table test_ixw674u7.t_rename_alter (0f1b84ac-c444-44d8-9e20-952b7b41ef44). (NO_SUCH_COLUMN_IN_TABLE) (version 25.3.6.10636.altinitytest (altinity build)) (from [::1]:40264) (comment: 03352_concurrent_rename_alter.sh) (query 1, line 1) (in query: INSERT INTO t_rename_alter (id, dt, arr_v2) SELECT 1, now(), [(now(), 1, 'a', 'b', 'c')]), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x000000000a6a1e2b 4. /build/src/Interpreters/InterpreterInsertQuery.cpp:258: DB::InterpreterInsertQuery::getSampleBlockImpl(std::vector> const&, std::shared_ptr const&, std::shared_ptr const&, bool, bool) @ 0x000000001492cf06 5. /build/src/Interpreters/InterpreterInsertQuery.cpp:200: DB::InterpreterInsertQuery::getSampleBlock(DB::ASTInsertQuery const&, std::shared_ptr const&, std::shared_ptr const&, std::shared_ptr, bool, bool) @ 0x000000001492c400 6. /build/src/Interpreters/InterpreterInsertQuery.cpp:838: DB::InterpreterInsertQuery::execute() @ 0x0000000014933ae7 7. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88dc9 8. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 9. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 10. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 11. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 12. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 13. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 14. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 15. ? @ 0x00007fbc6213eac3 16. ? @ 0x00007fbc621d0850 2025.07.28 11:53:39.341477 [ 5825 ] {58e46ce3-8e92-4d73-926a-e55ecf17ad7d} executeQuery: Code: 16. DB::Exception: No such column arr_v2 in table test_ixw674u7.t_rename_alter (0f1b84ac-c444-44d8-9e20-952b7b41ef44). (NO_SUCH_COLUMN_IN_TABLE) (version 25.3.6.10636.altinitytest (altinity build)) (from [::1]:40258) (comment: 03352_concurrent_rename_alter.sh) (query 1, line 1) (in query: INSERT INTO t_rename_alter (id, dt, arr_v2) SELECT 1, now(), [(now(), 1, 'a', 'b', 'c')]), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x000000000a6a1e2b 4. /build/src/Interpreters/InterpreterInsertQuery.cpp:258: DB::InterpreterInsertQuery::getSampleBlockImpl(std::vector> const&, std::shared_ptr const&, std::shared_ptr const&, bool, bool) @ 0x000000001492cf06 5. /build/src/Interpreters/InterpreterInsertQuery.cpp:200: DB::InterpreterInsertQuery::getSampleBlock(DB::ASTInsertQuery const&, std::shared_ptr const&, std::shared_ptr const&, std::shared_ptr, bool, bool) @ 0x000000001492c400 6. /build/src/Interpreters/InterpreterInsertQuery.cpp:838: DB::InterpreterInsertQuery::execute() @ 0x0000000014933ae7 7. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88dc9 8. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 9. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 10. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 11. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 12. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 13. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 14. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 15. ? @ 0x00007fbc6213eac3 16. ? @ 0x00007fbc621d0850 2025.07.28 11:53:39.352524 [ 5825 ] {} TCPHandler: Code: 16. DB::Exception: No such column arr_v2 in table test_ixw674u7.t_rename_alter (0f1b84ac-c444-44d8-9e20-952b7b41ef44). (NO_SUCH_COLUMN_IN_TABLE), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x000000000a6a1e2b 4. /build/src/Interpreters/InterpreterInsertQuery.cpp:258: DB::InterpreterInsertQuery::getSampleBlockImpl(std::vector> const&, std::shared_ptr const&, std::shared_ptr const&, bool, bool) @ 0x000000001492cf06 5. /build/src/Interpreters/InterpreterInsertQuery.cpp:200: DB::InterpreterInsertQuery::getSampleBlock(DB::ASTInsertQuery const&, std::shared_ptr const&, std::shared_ptr const&, std::shared_ptr, bool, bool) @ 0x000000001492c400 6. /build/src/Interpreters/InterpreterInsertQuery.cpp:838: DB::InterpreterInsertQuery::execute() @ 0x0000000014933ae7 7. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88dc9 8. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 9. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 10. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 11. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 12. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 13. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 14. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 15. ? @ 0x00007fbc6213eac3 16. ? @ 0x00007fbc621d0850 2025.07.28 11:53:39.393673 [ 4580 ] {} TCPHandler: Code: 16. DB::Exception: No such column arr_v2 in table test_ixw674u7.t_rename_alter (0f1b84ac-c444-44d8-9e20-952b7b41ef44). (NO_SUCH_COLUMN_IN_TABLE), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x000000000a6a1e2b 4. /build/src/Interpreters/InterpreterInsertQuery.cpp:258: DB::InterpreterInsertQuery::getSampleBlockImpl(std::vector> const&, std::shared_ptr const&, std::shared_ptr const&, bool, bool) @ 0x000000001492cf06 5. /build/src/Interpreters/InterpreterInsertQuery.cpp:200: DB::InterpreterInsertQuery::getSampleBlock(DB::ASTInsertQuery const&, std::shared_ptr const&, std::shared_ptr const&, std::shared_ptr, bool, bool) @ 0x000000001492c400 6. /build/src/Interpreters/InterpreterInsertQuery.cpp:838: DB::InterpreterInsertQuery::execute() @ 0x0000000014933ae7 7. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88dc9 8. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 9. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 10. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 11. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 12. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 13. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 14. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 15. ? @ 0x00007fbc6213eac3 16. ? @ 0x00007fbc621d0850 2025.07.28 11:53:39.394137 [ 17261 ] {8aab119a-b2ee-46e2-bf21-9c5eba350bd6} 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.6.10636.altinitytest (altinity build)) (from [::1]:40068) (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. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, char const*&&, String&&, unsigned long const&) @ 0x000000000ea7a24b 4. /build/src/Functions/array/arrayAUC.cpp:263: DB::FunctionArrayAUC::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000ea7e29b 5. /build/src/Functions/IFunctionAdaptors.cpp:10: DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000012d995fa 6. /build/src/Functions/IFunction.cpp:353: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d93b52 7. /build/src/Functions/IFunction.cpp:420: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d95059 8. /build/src/Functions/IFunction.cpp:498: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d95c72 9. /build/src/Interpreters/ExpressionActions.cpp:636: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x00000000145176f3 10. /build/src/Processors/Transforms/ExpressionTransform.cpp:25: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x0000000016c0b34c 11. /build/src/Processors/ISimpleTransform.h:33: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000011a9a453 12. /build/src/Processors/ISimpleTransform.cpp:89: DB::ISimpleTransform::work() @ 0x000000001699fca0 13. /build/src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x00000000169bd00f 14. /build/src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x00000000169b2105 15. /build/src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeSingleThread(unsigned long) @ 0x00000000169b23be 16. /build/src/Processors/Executors/PipelineExecutor.cpp:416: void std::__function::__policy_invoker::__call_impl[abi:se190107]>(std::__function::__policy_storage const*) @ 0x00000000169b2e3f 17. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc6653 18. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000000fccc4c3 19. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc3d92 20. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fcca080 21. ? @ 0x00007fbc6213eac3 22. ? @ 0x00007fbc621d0850 2025.07.28 11:53:39.394297 [ 17203 ] {88cead97-1df0-405c-a361-cfe2f4829b52} executeQuery: Code: 16. DB::Exception: No such column arr_v2 in table test_ixw674u7.t_rename_alter (0f1b84ac-c444-44d8-9e20-952b7b41ef44). (NO_SUCH_COLUMN_IN_TABLE) (version 25.3.6.10636.altinitytest (altinity build)) (from [::1]:40260) (comment: 03352_concurrent_rename_alter.sh) (query 1, line 1) (in query: INSERT INTO t_rename_alter (id, dt, arr_v2) SELECT 1, now(), [(now(), 1, 'a', 'b', 'c')]), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x000000000a6a1e2b 4. /build/src/Interpreters/InterpreterInsertQuery.cpp:258: DB::InterpreterInsertQuery::getSampleBlockImpl(std::vector> const&, std::shared_ptr const&, std::shared_ptr const&, bool, bool) @ 0x000000001492cf06 5. /build/src/Interpreters/InterpreterInsertQuery.cpp:200: DB::InterpreterInsertQuery::getSampleBlock(DB::ASTInsertQuery const&, std::shared_ptr const&, std::shared_ptr const&, std::shared_ptr, bool, bool) @ 0x000000001492c400 6. /build/src/Interpreters/InterpreterInsertQuery.cpp:838: DB::InterpreterInsertQuery::execute() @ 0x0000000014933ae7 7. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88dc9 8. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 9. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 10. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 11. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 12. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 13. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 14. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 15. ? @ 0x00007fbc6213eac3 16. ? @ 0x00007fbc621d0850 2025.07.28 11:53:39.399103 [ 17261 ] {} 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. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, char const*&&, String&&, unsigned long const&) @ 0x000000000ea7a24b 4. /build/src/Functions/array/arrayAUC.cpp:263: DB::FunctionArrayAUC::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000ea7e29b 5. /build/src/Functions/IFunctionAdaptors.cpp:10: DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000012d995fa 6. /build/src/Functions/IFunction.cpp:353: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d93b52 7. /build/src/Functions/IFunction.cpp:420: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d95059 8. /build/src/Functions/IFunction.cpp:498: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d95c72 9. /build/src/Interpreters/ExpressionActions.cpp:636: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x00000000145176f3 10. /build/src/Processors/Transforms/ExpressionTransform.cpp:25: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x0000000016c0b34c 11. /build/src/Processors/ISimpleTransform.h:33: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000011a9a453 12. /build/src/Processors/ISimpleTransform.cpp:89: DB::ISimpleTransform::work() @ 0x000000001699fca0 13. /build/src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x00000000169bd00f 14. /build/src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x00000000169b2105 15. /build/src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeSingleThread(unsigned long) @ 0x00000000169b23be 16. /build/src/Processors/Executors/PipelineExecutor.cpp:416: void std::__function::__policy_invoker::__call_impl[abi:se190107]>(std::__function::__policy_storage const*) @ 0x00000000169b2e3f 17. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc6653 18. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000000fccc4c3 19. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc3d92 20. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fcca080 21. ? @ 0x00007fbc6213eac3 22. ? @ 0x00007fbc621d0850 Job's origin stack trace: 0. /build/src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000000fc33b84 1. /build/src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000000fcc2ea7 2. /build/src/Common/ThreadPool.cpp:401: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fcc7f1c 3. /build/src/Common/ThreadPool.cpp:494: ThreadPoolImpl>::scheduleOrThrowOnError(std::function, Priority) @ 0x000000000fcc7a0e 4. /build/src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::spawnThreadsImpl() @ 0x00000000169b2c0c 5. /build/src/Processors/Executors/PipelineExecutor.cpp:394: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x00000000169b0ba7 6. /build/src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x00000000169b03f4 7. /build/src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:se190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169bfeab 8. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc3d92 9. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fcca080 10. ? @ 0x00007fbc6213eac3 11. ? @ 0x00007fbc621d0850 Job's origin stack trace: 0. /build/src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000000fc33b84 1. /build/src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000000fcc2ea7 2. /build/src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fcc535c 3. /build/src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000000fcc584d 4. /build/src/Common/ThreadPool.h:279: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x00000000169bf193 5. /build/src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x00000000169bf518 6. /build/src/Server/TCPHandler.cpp:1237: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x00000000168f1525 7. /build/src/Server/TCPHandler.cpp:678: DB::TCPHandler::runImpl() @ 0x00000000168e68e5 8. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 9. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 10. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 11. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 12. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 13. ? @ 0x00007fbc6213eac3 14. ? @ 0x00007fbc621d0850 2025.07.28 11:53:39.408400 [ 17203 ] {} TCPHandler: Code: 16. DB::Exception: No such column arr_v2 in table test_ixw674u7.t_rename_alter (0f1b84ac-c444-44d8-9e20-952b7b41ef44). (NO_SUCH_COLUMN_IN_TABLE), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x000000000a6a1e2b 4. /build/src/Interpreters/InterpreterInsertQuery.cpp:258: DB::InterpreterInsertQuery::getSampleBlockImpl(std::vector> const&, std::shared_ptr const&, std::shared_ptr const&, bool, bool) @ 0x000000001492cf06 5. /build/src/Interpreters/InterpreterInsertQuery.cpp:200: DB::InterpreterInsertQuery::getSampleBlock(DB::ASTInsertQuery const&, std::shared_ptr const&, std::shared_ptr const&, std::shared_ptr, bool, bool) @ 0x000000001492c400 6. /build/src/Interpreters/InterpreterInsertQuery.cpp:838: DB::InterpreterInsertQuery::execute() @ 0x0000000014933ae7 7. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88dc9 8. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 9. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 10. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 11. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 12. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 13. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 14. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 15. ? @ 0x00007fbc6213eac3 16. ? @ 0x00007fbc621d0850 2025.07.28 11:53:39.546709 [ 4963 ] {41d650ee-bc67-44a5-ade4-53eda263ba0d} executeQuery: Code: 16. DB::Exception: No such column arr_v2 in table test_ixw674u7.t_rename_alter (0f1b84ac-c444-44d8-9e20-952b7b41ef44). (NO_SUCH_COLUMN_IN_TABLE) (version 25.3.6.10636.altinitytest (altinity build)) (from [::1]:40322) (comment: 03352_concurrent_rename_alter.sh) (query 1, line 1) (in query: INSERT INTO t_rename_alter (id, dt, arr_v2) SELECT 1, now(), [(now(), 1, 'a', 'b', 'c')]), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x000000000a6a1e2b 4. /build/src/Interpreters/InterpreterInsertQuery.cpp:258: DB::InterpreterInsertQuery::getSampleBlockImpl(std::vector> const&, std::shared_ptr const&, std::shared_ptr const&, bool, bool) @ 0x000000001492cf06 5. /build/src/Interpreters/InterpreterInsertQuery.cpp:200: DB::InterpreterInsertQuery::getSampleBlock(DB::ASTInsertQuery const&, std::shared_ptr const&, std::shared_ptr const&, std::shared_ptr, bool, bool) @ 0x000000001492c400 6. /build/src/Interpreters/InterpreterInsertQuery.cpp:838: DB::InterpreterInsertQuery::execute() @ 0x0000000014933ae7 7. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88dc9 8. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 9. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 10. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 11. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 12. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 13. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 14. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 15. ? @ 0x00007fbc6213eac3 16. ? @ 0x00007fbc621d0850 2025.07.28 11:53:39.571808 [ 4963 ] {} TCPHandler: Code: 16. DB::Exception: No such column arr_v2 in table test_ixw674u7.t_rename_alter (0f1b84ac-c444-44d8-9e20-952b7b41ef44). (NO_SUCH_COLUMN_IN_TABLE), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x000000000a6a1e2b 4. /build/src/Interpreters/InterpreterInsertQuery.cpp:258: DB::InterpreterInsertQuery::getSampleBlockImpl(std::vector> const&, std::shared_ptr const&, std::shared_ptr const&, bool, bool) @ 0x000000001492cf06 5. /build/src/Interpreters/InterpreterInsertQuery.cpp:200: DB::InterpreterInsertQuery::getSampleBlock(DB::ASTInsertQuery const&, std::shared_ptr const&, std::shared_ptr const&, std::shared_ptr, bool, bool) @ 0x000000001492c400 6. /build/src/Interpreters/InterpreterInsertQuery.cpp:838: DB::InterpreterInsertQuery::execute() @ 0x0000000014933ae7 7. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88dc9 8. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 9. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 10. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 11. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 12. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 13. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 14. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 15. ? @ 0x00007fbc6213eac3 16. ? @ 0x00007fbc621d0850 2025.07.28 11:53:39.577906 [ 17287 ] {a3126a1a-bde0-4a31-9b7d-aec1c8546535} executeQuery: Code: 16. DB::Exception: No such column arr_v2 in table test_ixw674u7.t_rename_alter (0f1b84ac-c444-44d8-9e20-952b7b41ef44). (NO_SUCH_COLUMN_IN_TABLE) (version 25.3.6.10636.altinitytest (altinity build)) (from [::1]:40326) (comment: 03352_concurrent_rename_alter.sh) (query 1, line 1) (in query: INSERT INTO t_rename_alter (id, dt, arr_v2) SELECT 1, now(), [(now(), 1, 'a', 'b', 'c')]), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x000000000a6a1e2b 4. /build/src/Interpreters/InterpreterInsertQuery.cpp:258: DB::InterpreterInsertQuery::getSampleBlockImpl(std::vector> const&, std::shared_ptr const&, std::shared_ptr const&, bool, bool) @ 0x000000001492cf06 5. /build/src/Interpreters/InterpreterInsertQuery.cpp:200: DB::InterpreterInsertQuery::getSampleBlock(DB::ASTInsertQuery const&, std::shared_ptr const&, std::shared_ptr const&, std::shared_ptr, bool, bool) @ 0x000000001492c400 6. /build/src/Interpreters/InterpreterInsertQuery.cpp:838: DB::InterpreterInsertQuery::execute() @ 0x0000000014933ae7 7. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88dc9 8. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 9. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 10. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 11. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 12. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 13. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 14. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 15. ? @ 0x00007fbc6213eac3 16. ? @ 0x00007fbc621d0850 2025.07.28 11:53:39.588316 [ 17287 ] {} TCPHandler: Code: 16. DB::Exception: No such column arr_v2 in table test_ixw674u7.t_rename_alter (0f1b84ac-c444-44d8-9e20-952b7b41ef44). (NO_SUCH_COLUMN_IN_TABLE), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x000000000a6a1e2b 4. /build/src/Interpreters/InterpreterInsertQuery.cpp:258: DB::InterpreterInsertQuery::getSampleBlockImpl(std::vector> const&, std::shared_ptr const&, std::shared_ptr const&, bool, bool) @ 0x000000001492cf06 5. /build/src/Interpreters/InterpreterInsertQuery.cpp:200: DB::InterpreterInsertQuery::getSampleBlock(DB::ASTInsertQuery const&, std::shared_ptr const&, std::shared_ptr const&, std::shared_ptr, bool, bool) @ 0x000000001492c400 6. /build/src/Interpreters/InterpreterInsertQuery.cpp:838: DB::InterpreterInsertQuery::execute() @ 0x0000000014933ae7 7. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88dc9 8. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 9. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 10. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 11. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 12. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 13. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 14. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 15. ? @ 0x00007fbc6213eac3 16. ? @ 0x00007fbc621d0850 2025.07.28 11:53:39.662182 [ 3971 ] {} test_13.rmt2 (7f9b740d-015c-470e-8cc6-8ba33be0dc63): auto DB::StorageReplicatedMergeTree::processQueueEntry(ReplicatedMergeTreeQueue::SelectedEntryPtr)::(anonymous class)::operator()(LogEntryPtr &) const: Code: 86. DB::HTTPException: Received error from remote server http://146b4357c08d:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Ftest%2F01165%2Ftest_13%2Frmt%2Freplicas%2F1&part=20250728_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.6.10636.altinitytest (altinity build)) '. (RECEIVED_ERROR_FROM_REMOTE_IO_SERVER), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.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 const&, int&&, String const&, unsigned long&&, String const&) @ 0x000000000feda8d9 4. /build/src/IO/HTTPCommon.cpp:104: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x000000000feda6e2 5. /build/src/IO/HTTPCommon.cpp:93: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x000000000feda537 6. /build/src/IO/ReadWriteBufferFromHTTP.cpp:277: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x000000001184a4c4 7. /build/src/IO/ReadWriteBufferFromHTTP.cpp:285: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x000000001184a615 8. /build/src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x000000001184ae59 9. /build/src/IO/ReadWriteBufferFromHTTP.cpp:472: void std::__function::__policy_invoker::__call_impl[abi:se190107]>(std::__function::__policy_storage const*) @ 0x000000001184cedd 10. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001184858b 11. /build/src/IO/ReadWriteBufferFromHTTP.cpp:465: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x000000001184bf0b 12. /build/src/IO/ReadBuffer.h:60: DB::ReadBuffer::next() @ 0x000000000a148c7b 13. /build/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) @ 0x0000000011849fb2 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]>&)>&, 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&) @ 0x0000000011841980 15. /build/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) @ 0x000000001621208e 16. /build/src/Storages/StorageReplicatedMergeTree.cpp:5228: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl[abi:se190107] const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000015f9a5fe 17. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000015ed8bfd 18. /build/src/Storages/StorageReplicatedMergeTree.cpp:2514: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x0000000015ec9aab 19. /build/src/Storages/StorageReplicatedMergeTree.cpp:2349: DB::StorageReplicatedMergeTree::executeLogEntry(DB::ReplicatedMergeTreeLogEntry&) @ 0x0000000015eba91b 20. /build/src/Storages/StorageReplicatedMergeTree.cpp:3876: bool std::__function::__policy_invoker&)>::__call_impl[abi:se190107])::$_1, bool (std::shared_ptr&)>>(std::__function::__policy_storage const*, std::shared_ptr&) @ 0x0000000015f9837e 21. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000165d6fc3 22. /build/src/Storages/StorageReplicatedMergeTree.cpp:3872: DB::StorageReplicatedMergeTree::processQueueEntry(std::shared_ptr) @ 0x0000000015efc18a 23. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001624c1b2 24. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000162f9c70 25. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x00000000162fa55a 26. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc6653 27. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000000fccc4c3 28. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc3d92 29. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fcca080 30. ? @ 0x00007fbc6213eac3 31. ? @ 0x00007fbc621d0850 (version 25.3.6.10636.altinitytest (altinity build)) 2025.07.28 11:53:39.678737 [ 17255 ] {55978a16-3c74-4c85-9069-b60407333408} executeQuery: Code: 16. DB::Exception: No such column arr_v2 in table test_ixw674u7.t_rename_alter (0f1b84ac-c444-44d8-9e20-952b7b41ef44). (NO_SUCH_COLUMN_IN_TABLE) (version 25.3.6.10636.altinitytest (altinity build)) (from [::1]:40428) (comment: 03352_concurrent_rename_alter.sh) (query 1, line 1) (in query: INSERT INTO t_rename_alter (id, dt, arr_v2) SELECT 1, now(), [(now(), 1, 'a', 'b', 'c')]), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x000000000a6a1e2b 4. /build/src/Interpreters/InterpreterInsertQuery.cpp:258: DB::InterpreterInsertQuery::getSampleBlockImpl(std::vector> const&, std::shared_ptr const&, std::shared_ptr const&, bool, bool) @ 0x000000001492cf06 5. /build/src/Interpreters/InterpreterInsertQuery.cpp:200: DB::InterpreterInsertQuery::getSampleBlock(DB::ASTInsertQuery const&, std::shared_ptr const&, std::shared_ptr const&, std::shared_ptr, bool, bool) @ 0x000000001492c400 6. /build/src/Interpreters/InterpreterInsertQuery.cpp:838: DB::InterpreterInsertQuery::execute() @ 0x0000000014933ae7 7. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88dc9 8. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 9. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 10. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 11. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 12. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 13. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 14. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 15. ? @ 0x00007fbc6213eac3 16. ? @ 0x00007fbc621d0850 2025.07.28 11:53:39.691495 [ 5951 ] {f26b2205-b2f6-4ed0-8789-ed280245b73c} executeQuery: Code: 16. DB::Exception: No such column arr_v2 in table test_ixw674u7.t_rename_alter (0f1b84ac-c444-44d8-9e20-952b7b41ef44). (NO_SUCH_COLUMN_IN_TABLE) (version 25.3.6.10636.altinitytest (altinity build)) (from [::1]:40430) (comment: 03352_concurrent_rename_alter.sh) (query 1, line 1) (in query: INSERT INTO t_rename_alter (id, dt, arr_v2) SELECT 1, now(), [(now(), 1, 'a', 'b', 'c')]), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x000000000a6a1e2b 4. /build/src/Interpreters/InterpreterInsertQuery.cpp:258: DB::InterpreterInsertQuery::getSampleBlockImpl(std::vector> const&, std::shared_ptr const&, std::shared_ptr const&, bool, bool) @ 0x000000001492cf06 5. /build/src/Interpreters/InterpreterInsertQuery.cpp:200: DB::InterpreterInsertQuery::getSampleBlock(DB::ASTInsertQuery const&, std::shared_ptr const&, std::shared_ptr const&, std::shared_ptr, bool, bool) @ 0x000000001492c400 6. /build/src/Interpreters/InterpreterInsertQuery.cpp:838: DB::InterpreterInsertQuery::execute() @ 0x0000000014933ae7 7. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88dc9 8. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 9. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 10. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 11. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 12. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 13. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 14. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 15. ? @ 0x00007fbc6213eac3 16. ? @ 0x00007fbc621d0850 2025.07.28 11:53:39.693858 [ 17255 ] {} TCPHandler: Code: 16. DB::Exception: No such column arr_v2 in table test_ixw674u7.t_rename_alter (0f1b84ac-c444-44d8-9e20-952b7b41ef44). (NO_SUCH_COLUMN_IN_TABLE), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x000000000a6a1e2b 4. /build/src/Interpreters/InterpreterInsertQuery.cpp:258: DB::InterpreterInsertQuery::getSampleBlockImpl(std::vector> const&, std::shared_ptr const&, std::shared_ptr const&, bool, bool) @ 0x000000001492cf06 5. /build/src/Interpreters/InterpreterInsertQuery.cpp:200: DB::InterpreterInsertQuery::getSampleBlock(DB::ASTInsertQuery const&, std::shared_ptr const&, std::shared_ptr const&, std::shared_ptr, bool, bool) @ 0x000000001492c400 6. /build/src/Interpreters/InterpreterInsertQuery.cpp:838: DB::InterpreterInsertQuery::execute() @ 0x0000000014933ae7 7. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88dc9 8. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 9. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 10. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 11. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 12. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 13. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 14. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 15. ? @ 0x00007fbc6213eac3 16. ? @ 0x00007fbc621d0850 2025.07.28 11:53:39.738390 [ 5951 ] {} TCPHandler: Code: 16. DB::Exception: No such column arr_v2 in table test_ixw674u7.t_rename_alter (0f1b84ac-c444-44d8-9e20-952b7b41ef44). (NO_SUCH_COLUMN_IN_TABLE), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x000000000a6a1e2b 4. /build/src/Interpreters/InterpreterInsertQuery.cpp:258: DB::InterpreterInsertQuery::getSampleBlockImpl(std::vector> const&, std::shared_ptr const&, std::shared_ptr const&, bool, bool) @ 0x000000001492cf06 5. /build/src/Interpreters/InterpreterInsertQuery.cpp:200: DB::InterpreterInsertQuery::getSampleBlock(DB::ASTInsertQuery const&, std::shared_ptr const&, std::shared_ptr const&, std::shared_ptr, bool, bool) @ 0x000000001492c400 6. /build/src/Interpreters/InterpreterInsertQuery.cpp:838: DB::InterpreterInsertQuery::execute() @ 0x0000000014933ae7 7. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88dc9 8. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 9. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 10. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 11. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 12. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 13. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 14. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 15. ? @ 0x00007fbc6213eac3 16. ? @ 0x00007fbc621d0850 2025.07.28 11:53:39.896873 [ 17611 ] {3a07a0dd-d22a-4757-97c2-0095b639bb07} executeQuery: Code: 16. DB::Exception: No such column arr_v2 in table test_ixw674u7.t_rename_alter (0f1b84ac-c444-44d8-9e20-952b7b41ef44). (NO_SUCH_COLUMN_IN_TABLE) (version 25.3.6.10636.altinitytest (altinity build)) (from [::1]:40432) (comment: 03352_concurrent_rename_alter.sh) (query 1, line 1) (in query: INSERT INTO t_rename_alter (id, dt, arr_v2) SELECT 1, now(), [(now(), 1, 'a', 'b', 'c')]), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x000000000a6a1e2b 4. /build/src/Interpreters/InterpreterInsertQuery.cpp:258: DB::InterpreterInsertQuery::getSampleBlockImpl(std::vector> const&, std::shared_ptr const&, std::shared_ptr const&, bool, bool) @ 0x000000001492cf06 5. /build/src/Interpreters/InterpreterInsertQuery.cpp:200: DB::InterpreterInsertQuery::getSampleBlock(DB::ASTInsertQuery const&, std::shared_ptr const&, std::shared_ptr const&, std::shared_ptr, bool, bool) @ 0x000000001492c400 6. /build/src/Interpreters/InterpreterInsertQuery.cpp:838: DB::InterpreterInsertQuery::execute() @ 0x0000000014933ae7 7. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88dc9 8. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 9. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 10. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 11. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 12. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 13. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 14. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 15. ? @ 0x00007fbc6213eac3 16. ? @ 0x00007fbc621d0850 2025.07.28 11:53:39.922634 [ 5327 ] {5e632a9f-2d9c-412d-b0b1-fa35e14c201c} executeQuery: Code: 16. DB::Exception: No such column arr_v2 in table test_ixw674u7.t_rename_alter (0f1b84ac-c444-44d8-9e20-952b7b41ef44). (NO_SUCH_COLUMN_IN_TABLE) (version 25.3.6.10636.altinitytest (altinity build)) (from [::1]:40444) (comment: 03352_concurrent_rename_alter.sh) (query 1, line 1) (in query: INSERT INTO t_rename_alter (id, dt, arr_v2) SELECT 1, now(), [(now(), 1, 'a', 'b', 'c')]), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x000000000a6a1e2b 4. /build/src/Interpreters/InterpreterInsertQuery.cpp:258: DB::InterpreterInsertQuery::getSampleBlockImpl(std::vector> const&, std::shared_ptr const&, std::shared_ptr const&, bool, bool) @ 0x000000001492cf06 5. /build/src/Interpreters/InterpreterInsertQuery.cpp:200: DB::InterpreterInsertQuery::getSampleBlock(DB::ASTInsertQuery const&, std::shared_ptr const&, std::shared_ptr const&, std::shared_ptr, bool, bool) @ 0x000000001492c400 6. /build/src/Interpreters/InterpreterInsertQuery.cpp:838: DB::InterpreterInsertQuery::execute() @ 0x0000000014933ae7 7. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88dc9 8. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 9. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 10. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 11. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 12. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 13. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 14. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 15. ? @ 0x00007fbc6213eac3 16. ? @ 0x00007fbc621d0850 2025.07.28 11:53:39.925932 [ 17611 ] {} TCPHandler: Code: 16. DB::Exception: No such column arr_v2 in table test_ixw674u7.t_rename_alter (0f1b84ac-c444-44d8-9e20-952b7b41ef44). (NO_SUCH_COLUMN_IN_TABLE), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x000000000a6a1e2b 4. /build/src/Interpreters/InterpreterInsertQuery.cpp:258: DB::InterpreterInsertQuery::getSampleBlockImpl(std::vector> const&, std::shared_ptr const&, std::shared_ptr const&, bool, bool) @ 0x000000001492cf06 5. /build/src/Interpreters/InterpreterInsertQuery.cpp:200: DB::InterpreterInsertQuery::getSampleBlock(DB::ASTInsertQuery const&, std::shared_ptr const&, std::shared_ptr const&, std::shared_ptr, bool, bool) @ 0x000000001492c400 6. /build/src/Interpreters/InterpreterInsertQuery.cpp:838: DB::InterpreterInsertQuery::execute() @ 0x0000000014933ae7 7. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88dc9 8. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 9. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 10. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 11. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 12. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 13. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 14. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 15. ? @ 0x00007fbc6213eac3 16. ? @ 0x00007fbc621d0850 2025.07.28 11:53:39.932112 [ 4900 ] {} 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. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Access/AccessControl.cpp:646: DB::AccessControl::authenticate(DB::Credentials const&, Poco::Net::IPAddress const&, DB::ClientInfo const&) const @ 0x0000000013727552 4. /build/src/Interpreters/Session.cpp:371: DB::Session::authenticate(DB::Credentials const&, Poco::Net::SocketAddress const&, std::vector> const&) @ 0x0000000014a6dd4d 5. /build/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) @ 0x0000000016910eed 6. /build/src/Server/HTTPHandler.cpp:208: DB::HTTPHandler::authenticateUser(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&) @ 0x000000001686a6b6 7. /build/src/Server/HTTPHandler.cpp:224: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000001686aaa7 8. /build/src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x0000000016870807 9. /build/src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x0000000016907e99 10. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 11. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 12. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 13. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 14. ? @ 0x00007fbc6213eac3 15. ? @ 0x00007fbc621d0850 (version 25.3.6.10636.altinitytest (altinity build)) 2025.07.28 11:53:39.936329 [ 17255 ] {776c3eba-6c1b-49a0-895b-e336af470fbd} executeQuery: Code: 16. DB::Exception: No such column arr_v2 in table test_ixw674u7.t_rename_alter (0f1b84ac-c444-44d8-9e20-952b7b41ef44). (NO_SUCH_COLUMN_IN_TABLE) (version 25.3.6.10636.altinitytest (altinity build)) (from [::1]:40446) (comment: 03352_concurrent_rename_alter.sh) (query 1, line 1) (in query: INSERT INTO t_rename_alter (id, dt, arr_v2) SELECT 1, now(), [(now(), 1, 'a', 'b', 'c')]), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x000000000a6a1e2b 4. /build/src/Interpreters/InterpreterInsertQuery.cpp:258: DB::InterpreterInsertQuery::getSampleBlockImpl(std::vector> const&, std::shared_ptr const&, std::shared_ptr const&, bool, bool) @ 0x000000001492cf06 5. /build/src/Interpreters/InterpreterInsertQuery.cpp:200: DB::InterpreterInsertQuery::getSampleBlock(DB::ASTInsertQuery const&, std::shared_ptr const&, std::shared_ptr const&, std::shared_ptr, bool, bool) @ 0x000000001492c400 6. /build/src/Interpreters/InterpreterInsertQuery.cpp:838: DB::InterpreterInsertQuery::execute() @ 0x0000000014933ae7 7. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88dc9 8. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 9. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 10. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 11. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 12. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 13. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 14. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 15. ? @ 0x00007fbc6213eac3 16. ? @ 0x00007fbc621d0850 2025.07.28 11:53:39.944397 [ 5327 ] {} TCPHandler: Code: 16. DB::Exception: No such column arr_v2 in table test_ixw674u7.t_rename_alter (0f1b84ac-c444-44d8-9e20-952b7b41ef44). (NO_SUCH_COLUMN_IN_TABLE), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x000000000a6a1e2b 4. /build/src/Interpreters/InterpreterInsertQuery.cpp:258: DB::InterpreterInsertQuery::getSampleBlockImpl(std::vector> const&, std::shared_ptr const&, std::shared_ptr const&, bool, bool) @ 0x000000001492cf06 5. /build/src/Interpreters/InterpreterInsertQuery.cpp:200: DB::InterpreterInsertQuery::getSampleBlock(DB::ASTInsertQuery const&, std::shared_ptr const&, std::shared_ptr const&, std::shared_ptr, bool, bool) @ 0x000000001492c400 6. /build/src/Interpreters/InterpreterInsertQuery.cpp:838: DB::InterpreterInsertQuery::execute() @ 0x0000000014933ae7 7. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88dc9 8. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 9. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 10. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 11. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 12. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 13. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 14. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 15. ? @ 0x00007fbc6213eac3 16. ? @ 0x00007fbc621d0850 2025.07.28 11:53:39.951851 [ 4900 ] {} 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. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Access/AccessControl.cpp:646: DB::AccessControl::authenticate(DB::Credentials const&, Poco::Net::IPAddress const&, DB::ClientInfo const&) const @ 0x0000000013727552 4. /build/src/Interpreters/Session.cpp:371: DB::Session::authenticate(DB::Credentials const&, Poco::Net::SocketAddress const&, std::vector> const&) @ 0x0000000014a6dd4d 5. /build/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) @ 0x0000000016910eed 6. /build/src/Server/HTTPHandler.cpp:208: DB::HTTPHandler::authenticateUser(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&) @ 0x000000001686a6b6 7. /build/src/Server/HTTPHandler.cpp:224: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000001686aaa7 8. /build/src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x0000000016870807 9. /build/src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x0000000016907e99 10. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 11. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 12. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 13. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 14. ? @ 0x00007fbc6213eac3 15. ? @ 0x00007fbc621d0850 (version 25.3.6.10636.altinitytest (altinity build)) 2025.07.28 11:53:39.972712 [ 17255 ] {} TCPHandler: Code: 16. DB::Exception: No such column arr_v2 in table test_ixw674u7.t_rename_alter (0f1b84ac-c444-44d8-9e20-952b7b41ef44). (NO_SUCH_COLUMN_IN_TABLE), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x000000000a6a1e2b 4. /build/src/Interpreters/InterpreterInsertQuery.cpp:258: DB::InterpreterInsertQuery::getSampleBlockImpl(std::vector> const&, std::shared_ptr const&, std::shared_ptr const&, bool, bool) @ 0x000000001492cf06 5. /build/src/Interpreters/InterpreterInsertQuery.cpp:200: DB::InterpreterInsertQuery::getSampleBlock(DB::ASTInsertQuery const&, std::shared_ptr const&, std::shared_ptr const&, std::shared_ptr, bool, bool) @ 0x000000001492c400 6. /build/src/Interpreters/InterpreterInsertQuery.cpp:838: DB::InterpreterInsertQuery::execute() @ 0x0000000014933ae7 7. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88dc9 8. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 9. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 10. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 11. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 12. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 13. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 14. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 15. ? @ 0x00007fbc6213eac3 16. ? @ 0x00007fbc621d0850 2025.07.28 11:53:40.118673 [ 17243 ] {95c7e173-89b5-436e-9324-5dcb9b71fb62} executeQuery: Code: 16. DB::Exception: No such column arr_v2 in table test_ixw674u7.t_rename_alter (0f1b84ac-c444-44d8-9e20-952b7b41ef44). (NO_SUCH_COLUMN_IN_TABLE) (version 25.3.6.10636.altinitytest (altinity build)) (from [::1]:40492) (comment: 03352_concurrent_rename_alter.sh) (query 1, line 1) (in query: INSERT INTO t_rename_alter (id, dt, arr_v2) SELECT 1, now(), [(now(), 1, 'a', 'b', 'c')]), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x000000000a6a1e2b 4. /build/src/Interpreters/InterpreterInsertQuery.cpp:258: DB::InterpreterInsertQuery::getSampleBlockImpl(std::vector> const&, std::shared_ptr const&, std::shared_ptr const&, bool, bool) @ 0x000000001492cf06 5. /build/src/Interpreters/InterpreterInsertQuery.cpp:200: DB::InterpreterInsertQuery::getSampleBlock(DB::ASTInsertQuery const&, std::shared_ptr const&, std::shared_ptr const&, std::shared_ptr, bool, bool) @ 0x000000001492c400 6. /build/src/Interpreters/InterpreterInsertQuery.cpp:838: DB::InterpreterInsertQuery::execute() @ 0x0000000014933ae7 7. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88dc9 8. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 9. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 10. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 11. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 12. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 13. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 14. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 15. ? @ 0x00007fbc6213eac3 16. ? @ 0x00007fbc621d0850 2025.07.28 11:53:40.120537 [ 12807 ] {f21021dd-efac-4290-a46a-674bf7d3a5df} 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.6.10636.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.6.10636.altinitytest (altinity build)) (from [::1]:34600) (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. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.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 const&, int&&, String const&, unsigned long&&, String const&) @ 0x000000000feda8d9 4. /build/src/IO/HTTPCommon.cpp:104: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x000000000feda6e2 5. /build/src/IO/HTTPCommon.cpp:93: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x000000000feda537 6. /build/src/IO/ReadWriteBufferFromHTTP.cpp:277: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x000000001184a4c4 7. /build/src/IO/ReadWriteBufferFromHTTP.cpp:285: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x000000001184a615 8. /build/src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x000000001184ae59 9. /build/src/IO/ReadWriteBufferFromHTTP.cpp:472: void std::__function::__policy_invoker::__call_impl[abi:se190107]>(std::__function::__policy_storage const*) @ 0x000000001184cedd 10. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001184858b 11. /build/src/IO/ReadWriteBufferFromHTTP.cpp:465: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x000000001184bf0b 12. /build/src/IO/ReadBuffer.h:60: DB::ReadBuffer::next() @ 0x000000000a148c7b 13. /build/src/IO/ReadBuffer.h:96: DB::LineAsStringRowInputFormat::readRow(std::vector::mutable_ptr, std::allocator::mutable_ptr>>&, DB::RowReadExtension&) @ 0x0000000016ad8f2d 14. /build/src/Processors/Formats/IRowInputFormat.cpp:143: DB::IRowInputFormat::read() @ 0x0000000016a1fc72 15. /build/src/Processors/Formats/IInputFormat.cpp:19: DB::IInputFormat::generate() @ 0x00000000169c5536 16. /build/src/Processors/ISource.cpp:139: DB::ISource::tryGenerate() @ 0x00000000169a24fa 17. /build/src/Processors/ISource.cpp:108: DB::ISource::work() @ 0x00000000169a21e7 18. /build/src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x00000000169bd00f 19. /build/src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x00000000169b2105 20. /build/src/Processors/Executors/PipelineExecutor.cpp:170: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x00000000169b16a7 21. /build/src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x00000000169c081c 22. /build/src/Storages/StorageURL.cpp:467: DB::StorageURLSource::generate() @ 0x000000001601f496 23. /build/src/Processors/ISource.cpp:139: DB::ISource::tryGenerate() @ 0x00000000169a24fa 24. /build/src/Processors/ISource.cpp:108: DB::ISource::work() @ 0x00000000169a21e7 25. /build/src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x00000000169bd00f 26. /build/src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x00000000169b2105 27. /build/src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeSingleThread(unsigned long) @ 0x00000000169b23be 28. /build/src/Processors/Executors/PipelineExecutor.cpp:454: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x00000000169b0be7 29. /build/src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x00000000169b03f4 30. /build/src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:se190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169bfeab 31. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc3d92 2025.07.28 11:53:40.183975 [ 17243 ] {} TCPHandler: Code: 16. DB::Exception: No such column arr_v2 in table test_ixw674u7.t_rename_alter (0f1b84ac-c444-44d8-9e20-952b7b41ef44). (NO_SUCH_COLUMN_IN_TABLE), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x000000000a6a1e2b 4. /build/src/Interpreters/InterpreterInsertQuery.cpp:258: DB::InterpreterInsertQuery::getSampleBlockImpl(std::vector> const&, std::shared_ptr const&, std::shared_ptr const&, bool, bool) @ 0x000000001492cf06 5. /build/src/Interpreters/InterpreterInsertQuery.cpp:200: DB::InterpreterInsertQuery::getSampleBlock(DB::ASTInsertQuery const&, std::shared_ptr const&, std::shared_ptr const&, std::shared_ptr, bool, bool) @ 0x000000001492c400 6. /build/src/Interpreters/InterpreterInsertQuery.cpp:838: DB::InterpreterInsertQuery::execute() @ 0x0000000014933ae7 7. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88dc9 8. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 9. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 10. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 11. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 12. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 13. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 14. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 15. ? @ 0x00007fbc6213eac3 16. ? @ 0x00007fbc621d0850 2025.07.28 11:53:40.184153 [ 17208 ] {1d106823-b063-46f0-9a1a-dcaccb61ef21} executeQuery: Code: 62. DB::Exception: Cannot TRUNCATE dictionary. (SYNTAX_ERROR) (version 25.3.6.10636.altinitytest (altinity build)) (from 0.0.0.0:0) (comment: 01854_HTTP_dict_decompression.sh) (in query: /* ddl_entry=query-0000000007 */ TRUNCATE DICTIONARY IF EXISTS test_grlrh7mz.test_table_select), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000000a074fcb 4. /build/src/Interpreters/InterpreterDropQuery.cpp:266: DB::InterpreterDropQuery::executeToTableImpl(std::shared_ptr const&, DB::ASTDropQuery&, std::shared_ptr&, StrongTypedef, DB::UUIDTag>&) @ 0x0000000014915b7b 5. /build/src/Interpreters/InterpreterDropQuery.cpp:118: DB::InterpreterDropQuery::executeToTable(DB::ASTDropQuery&) @ 0x00000000149137b4 6. /build/src/Interpreters/InterpreterDropQuery.cpp:91: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000014912f07 7. /build/src/Interpreters/InterpreterDropQuery.cpp:72: DB::InterpreterDropQuery::execute() @ 0x0000000014912b65 8. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88dc9 9. /build/src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x0000000014c8ca7b 10. /build/src/Interpreters/DDLWorker.cpp:510: DB::DDLWorker::tryExecuteQuery(DB::DDLTaskBase&, std::shared_ptr const&, bool) @ 0x00000000144dab9e 11. /build/src/Interpreters/DDLWorker.cpp:675: DB::DDLWorker::processTask(DB::DDLTaskBase&, std::shared_ptr const&, bool) @ 0x00000000144d8ffe 12. /build/src/Databases/DatabaseReplicatedWorker.cpp:372: DB::DatabaseReplicatedDDLWorker::tryEnqueueAndExecuteEntry(DB::DDLLogEntry&, std::shared_ptr, bool) @ 0x0000000013dc29ab 13. /build/src/Databases/DatabaseReplicated.cpp:1139: DB::DatabaseReplicated::tryEnqueueReplicatedDDL(std::shared_ptr const&, std::shared_ptr, DB::QueryFlags) @ 0x0000000013d9f73c 14. /build/src/Interpreters/InterpreterDropQuery.cpp:226: DB::InterpreterDropQuery::executeToTableImpl(std::shared_ptr const&, DB::ASTDropQuery&, std::shared_ptr&, StrongTypedef, DB::UUIDTag>&) @ 0x0000000014914ed7 15. /build/src/Interpreters/InterpreterDropQuery.cpp:118: DB::InterpreterDropQuery::executeToTable(DB::ASTDropQuery&) @ 0x00000000149137b4 16. /build/src/Interpreters/InterpreterDropQuery.cpp:91: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000014912f07 17. /build/src/Interpreters/InterpreterDropQuery.cpp:72: DB::InterpreterDropQuery::execute() @ 0x0000000014912b65 18. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88dc9 19. /build/src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x0000000014c8ca7b 20. /build/src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000001686da12 21. /build/src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x0000000016870807 22. /build/src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x0000000016907e99 23. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 24. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 25. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 26. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 27. ? @ 0x00007fbc6213eac3 28. ? @ 0x00007fbc621d0850 2025.07.28 11:53:40.189412 [ 12807 ] {} 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.6.10636.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. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.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 const&, int&&, String const&, unsigned long&&, String const&) @ 0x000000000feda8d9 4. /build/src/IO/HTTPCommon.cpp:104: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x000000000feda6e2 5. /build/src/IO/HTTPCommon.cpp:93: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x000000000feda537 6. /build/src/IO/ReadWriteBufferFromHTTP.cpp:277: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x000000001184a4c4 7. /build/src/IO/ReadWriteBufferFromHTTP.cpp:285: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x000000001184a615 8. /build/src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x000000001184ae59 9. /build/src/IO/ReadWriteBufferFromHTTP.cpp:472: void std::__function::__policy_invoker::__call_impl[abi:se190107]>(std::__function::__policy_storage const*) @ 0x000000001184cedd 10. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001184858b 11. /build/src/IO/ReadWriteBufferFromHTTP.cpp:465: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x000000001184bf0b 12. /build/src/IO/ReadBuffer.h:60: DB::ReadBuffer::next() @ 0x000000000a148c7b 13. /build/src/IO/ReadBuffer.h:96: DB::LineAsStringRowInputFormat::readRow(std::vector::mutable_ptr, std::allocator::mutable_ptr>>&, DB::RowReadExtension&) @ 0x0000000016ad8f2d 14. /build/src/Processors/Formats/IRowInputFormat.cpp:143: DB::IRowInputFormat::read() @ 0x0000000016a1fc72 15. /build/src/Processors/Formats/IInputFormat.cpp:19: DB::IInputFormat::generate() @ 0x00000000169c5536 16. /build/src/Processors/ISource.cpp:139: DB::ISource::tryGenerate() @ 0x00000000169a24fa 17. /build/src/Processors/ISource.cpp:108: DB::ISource::work() @ 0x00000000169a21e7 18. /build/src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x00000000169bd00f 19. /build/src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x00000000169b2105 20. /build/src/Processors/Executors/PipelineExecutor.cpp:170: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x00000000169b16a7 21. /build/src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x00000000169c081c 22. /build/src/Storages/StorageURL.cpp:467: DB::StorageURLSource::generate() @ 0x000000001601f496 23. /build/src/Processors/ISource.cpp:139: DB::ISource::tryGenerate() @ 0x00000000169a24fa 24. /build/src/Processors/ISource.cpp:108: DB::ISource::work() @ 0x00000000169a21e7 25. /build/src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x00000000169bd00f 26. /build/src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x00000000169b2105 27. /build/src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeSingleThread(unsigned long) @ 0x00000000169b23be 28. /build/src/Processors/Executors/PipelineExecutor.cpp:454: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x00000000169b0be7 29. /build/src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x00000000169b03f4 30. /build/src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:se190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169bfeab 31. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc3d92 Job's origin stack trace: 0. /build/src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000000fc33b84 1. /build/src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000000fcc2ea7 2. /build/src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fcc535c 3. /build/src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000000fcc584d 4. /build/src/Common/ThreadPool.h:279: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x00000000169bf193 5. /build/src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x00000000169bf518 6. /build/src/Server/TCPHandler.cpp:1237: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x00000000168f1525 7. /build/src/Server/TCPHandler.cpp:678: DB::TCPHandler::runImpl() @ 0x00000000168e68e5 8. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 9. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 10. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 11. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 12. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 13. ? @ 0x00007fbc6213eac3 14. ? @ 0x00007fbc621d0850 2025.07.28 11:53:40.196153 [ 17557 ] {290a844d-cc0b-4c0f-91b4-8bc8ca771a98} executeQuery: Code: 16. DB::Exception: No such column arr_v2 in table test_ixw674u7.t_rename_alter (0f1b84ac-c444-44d8-9e20-952b7b41ef44). (NO_SUCH_COLUMN_IN_TABLE) (version 25.3.6.10636.altinitytest (altinity build)) (from [::1]:40512) (comment: 03352_concurrent_rename_alter.sh) (query 1, line 1) (in query: INSERT INTO t_rename_alter (id, dt, arr_v2) SELECT 1, now(), [(now(), 1, 'a', 'b', 'c')]), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x000000000a6a1e2b 4. /build/src/Interpreters/InterpreterInsertQuery.cpp:258: DB::InterpreterInsertQuery::getSampleBlockImpl(std::vector> const&, std::shared_ptr const&, std::shared_ptr const&, bool, bool) @ 0x000000001492cf06 5. /build/src/Interpreters/InterpreterInsertQuery.cpp:200: DB::InterpreterInsertQuery::getSampleBlock(DB::ASTInsertQuery const&, std::shared_ptr const&, std::shared_ptr const&, std::shared_ptr, bool, bool) @ 0x000000001492c400 6. /build/src/Interpreters/InterpreterInsertQuery.cpp:838: DB::InterpreterInsertQuery::execute() @ 0x0000000014933ae7 7. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88dc9 8. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 9. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 10. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 11. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 12. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 13. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 14. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 15. ? @ 0x00007fbc6213eac3 16. ? @ 0x00007fbc621d0850 2025.07.28 11:53:40.207567 [ 17557 ] {} TCPHandler: Code: 16. DB::Exception: No such column arr_v2 in table test_ixw674u7.t_rename_alter (0f1b84ac-c444-44d8-9e20-952b7b41ef44). (NO_SUCH_COLUMN_IN_TABLE), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x000000000a6a1e2b 4. /build/src/Interpreters/InterpreterInsertQuery.cpp:258: DB::InterpreterInsertQuery::getSampleBlockImpl(std::vector> const&, std::shared_ptr const&, std::shared_ptr const&, bool, bool) @ 0x000000001492cf06 5. /build/src/Interpreters/InterpreterInsertQuery.cpp:200: DB::InterpreterInsertQuery::getSampleBlock(DB::ASTInsertQuery const&, std::shared_ptr const&, std::shared_ptr const&, std::shared_ptr, bool, bool) @ 0x000000001492c400 6. /build/src/Interpreters/InterpreterInsertQuery.cpp:838: DB::InterpreterInsertQuery::execute() @ 0x0000000014933ae7 7. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88dc9 8. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 9. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 10. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 11. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 12. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 13. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 14. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 15. ? @ 0x00007fbc6213eac3 16. ? @ 0x00007fbc621d0850 2025.07.28 11:53:40.254046 [ 3968 ] {} test_13.rmt2 (7f9b740d-015c-470e-8cc6-8ba33be0dc63): auto DB::StorageReplicatedMergeTree::processQueueEntry(ReplicatedMergeTreeQueue::SelectedEntryPtr)::(anonymous class)::operator()(LogEntryPtr &) const: Code: 86. DB::HTTPException: Received error from remote server http://146b4357c08d:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Ftest%2F01165%2Ftest_13%2Frmt%2Freplicas%2F1&part=20250728_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.6.10636.altinitytest (altinity build)) '. (RECEIVED_ERROR_FROM_REMOTE_IO_SERVER), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.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 const&, int&&, String const&, unsigned long&&, String const&) @ 0x000000000feda8d9 4. /build/src/IO/HTTPCommon.cpp:104: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x000000000feda6e2 5. /build/src/IO/HTTPCommon.cpp:93: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x000000000feda537 6. /build/src/IO/ReadWriteBufferFromHTTP.cpp:277: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x000000001184a4c4 7. /build/src/IO/ReadWriteBufferFromHTTP.cpp:285: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x000000001184a615 8. /build/src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x000000001184ae59 9. /build/src/IO/ReadWriteBufferFromHTTP.cpp:472: void std::__function::__policy_invoker::__call_impl[abi:se190107]>(std::__function::__policy_storage const*) @ 0x000000001184cedd 10. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001184858b 11. /build/src/IO/ReadWriteBufferFromHTTP.cpp:465: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x000000001184bf0b 12. /build/src/IO/ReadBuffer.h:60: DB::ReadBuffer::next() @ 0x000000000a148c7b 13. /build/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) @ 0x0000000011849fb2 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]>&)>&, 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&) @ 0x0000000011841980 15. /build/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) @ 0x000000001621208e 16. /build/src/Storages/StorageReplicatedMergeTree.cpp:5228: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl[abi:se190107] const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000015f9a5fe 17. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000015ed8bfd 18. /build/src/Storages/StorageReplicatedMergeTree.cpp:2514: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x0000000015ec9aab 19. /build/src/Storages/StorageReplicatedMergeTree.cpp:2349: DB::StorageReplicatedMergeTree::executeLogEntry(DB::ReplicatedMergeTreeLogEntry&) @ 0x0000000015eba91b 20. /build/src/Storages/StorageReplicatedMergeTree.cpp:3876: bool std::__function::__policy_invoker&)>::__call_impl[abi:se190107])::$_1, bool (std::shared_ptr&)>>(std::__function::__policy_storage const*, std::shared_ptr&) @ 0x0000000015f9837e 21. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000165d6fc3 22. /build/src/Storages/StorageReplicatedMergeTree.cpp:3872: DB::StorageReplicatedMergeTree::processQueueEntry(std::shared_ptr) @ 0x0000000015efc18a 23. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001624c1b2 24. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000162f9c70 25. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x00000000162fa55a 26. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc6653 27. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000000fccc4c3 28. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc3d92 29. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fcca080 30. ? @ 0x00007fbc6213eac3 31. ? @ 0x00007fbc621d0850 (version 25.3.6.10636.altinitytest (altinity build)) 2025.07.28 11:53:40.260654 [ 17208 ] {1d106823-b063-46f0-9a1a-dcaccb61ef21} executeQuery: Code: 62. DB::Exception: Cannot TRUNCATE dictionary. (SYNTAX_ERROR) (version 25.3.6.10636.altinitytest (altinity build)) (from [::1]:57556) (comment: 01854_HTTP_dict_decompression.sh) (in query: drop dictionary if exists test_table_select), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000000a074fcb 4. /build/src/Interpreters/InterpreterDropQuery.cpp:266: DB::InterpreterDropQuery::executeToTableImpl(std::shared_ptr const&, DB::ASTDropQuery&, std::shared_ptr&, StrongTypedef, DB::UUIDTag>&) @ 0x0000000014915b7b 5. /build/src/Interpreters/InterpreterDropQuery.cpp:118: DB::InterpreterDropQuery::executeToTable(DB::ASTDropQuery&) @ 0x00000000149137b4 6. /build/src/Interpreters/InterpreterDropQuery.cpp:91: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000014912f07 7. /build/src/Interpreters/InterpreterDropQuery.cpp:72: DB::InterpreterDropQuery::execute() @ 0x0000000014912b65 8. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88dc9 9. /build/src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x0000000014c8ca7b 10. /build/src/Interpreters/DDLWorker.cpp:510: DB::DDLWorker::tryExecuteQuery(DB::DDLTaskBase&, std::shared_ptr const&, bool) @ 0x00000000144dab9e 11. /build/src/Interpreters/DDLWorker.cpp:675: DB::DDLWorker::processTask(DB::DDLTaskBase&, std::shared_ptr const&, bool) @ 0x00000000144d8ffe 12. /build/src/Databases/DatabaseReplicatedWorker.cpp:372: DB::DatabaseReplicatedDDLWorker::tryEnqueueAndExecuteEntry(DB::DDLLogEntry&, std::shared_ptr, bool) @ 0x0000000013dc29ab 13. /build/src/Databases/DatabaseReplicated.cpp:1139: DB::DatabaseReplicated::tryEnqueueReplicatedDDL(std::shared_ptr const&, std::shared_ptr, DB::QueryFlags) @ 0x0000000013d9f73c 14. /build/src/Interpreters/InterpreterDropQuery.cpp:226: DB::InterpreterDropQuery::executeToTableImpl(std::shared_ptr const&, DB::ASTDropQuery&, std::shared_ptr&, StrongTypedef, DB::UUIDTag>&) @ 0x0000000014914ed7 15. /build/src/Interpreters/InterpreterDropQuery.cpp:118: DB::InterpreterDropQuery::executeToTable(DB::ASTDropQuery&) @ 0x00000000149137b4 16. /build/src/Interpreters/InterpreterDropQuery.cpp:91: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000014912f07 17. /build/src/Interpreters/InterpreterDropQuery.cpp:72: DB::InterpreterDropQuery::execute() @ 0x0000000014912b65 18. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88dc9 19. /build/src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x0000000014c8ca7b 20. /build/src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000001686da12 21. /build/src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x0000000016870807 22. /build/src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x0000000016907e99 23. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 24. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 25. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 26. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 27. ? @ 0x00007fbc6213eac3 28. ? @ 0x00007fbc621d0850 2025.07.28 11:53:40.262990 [ 17208 ] {1d106823-b063-46f0-9a1a-dcaccb61ef21} DynamicQueryHandler: Code: 62. DB::Exception: Cannot TRUNCATE dictionary. (SYNTAX_ERROR), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000000a074fcb 4. /build/src/Interpreters/InterpreterDropQuery.cpp:266: DB::InterpreterDropQuery::executeToTableImpl(std::shared_ptr const&, DB::ASTDropQuery&, std::shared_ptr&, StrongTypedef, DB::UUIDTag>&) @ 0x0000000014915b7b 5. /build/src/Interpreters/InterpreterDropQuery.cpp:118: DB::InterpreterDropQuery::executeToTable(DB::ASTDropQuery&) @ 0x00000000149137b4 6. /build/src/Interpreters/InterpreterDropQuery.cpp:91: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000014912f07 7. /build/src/Interpreters/InterpreterDropQuery.cpp:72: DB::InterpreterDropQuery::execute() @ 0x0000000014912b65 8. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88dc9 9. /build/src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x0000000014c8ca7b 10. /build/src/Interpreters/DDLWorker.cpp:510: DB::DDLWorker::tryExecuteQuery(DB::DDLTaskBase&, std::shared_ptr const&, bool) @ 0x00000000144dab9e 11. /build/src/Interpreters/DDLWorker.cpp:675: DB::DDLWorker::processTask(DB::DDLTaskBase&, std::shared_ptr const&, bool) @ 0x00000000144d8ffe 12. /build/src/Databases/DatabaseReplicatedWorker.cpp:372: DB::DatabaseReplicatedDDLWorker::tryEnqueueAndExecuteEntry(DB::DDLLogEntry&, std::shared_ptr, bool) @ 0x0000000013dc29ab 13. /build/src/Databases/DatabaseReplicated.cpp:1139: DB::DatabaseReplicated::tryEnqueueReplicatedDDL(std::shared_ptr const&, std::shared_ptr, DB::QueryFlags) @ 0x0000000013d9f73c 14. /build/src/Interpreters/InterpreterDropQuery.cpp:226: DB::InterpreterDropQuery::executeToTableImpl(std::shared_ptr const&, DB::ASTDropQuery&, std::shared_ptr&, StrongTypedef, DB::UUIDTag>&) @ 0x0000000014914ed7 15. /build/src/Interpreters/InterpreterDropQuery.cpp:118: DB::InterpreterDropQuery::executeToTable(DB::ASTDropQuery&) @ 0x00000000149137b4 16. /build/src/Interpreters/InterpreterDropQuery.cpp:91: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000014912f07 17. /build/src/Interpreters/InterpreterDropQuery.cpp:72: DB::InterpreterDropQuery::execute() @ 0x0000000014912b65 18. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88dc9 19. /build/src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x0000000014c8ca7b 20. /build/src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000001686da12 21. /build/src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x0000000016870807 22. /build/src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x0000000016907e99 23. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 24. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 25. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 26. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 27. ? @ 0x00007fbc6213eac3 28. ? @ 0x00007fbc621d0850 (version 25.3.6.10636.altinitytest (altinity build)) 2025.07.28 11:53:40.288785 [ 17208 ] {1d106823-b063-46f0-9a1a-dcaccb61ef21} 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 ([::1]:8123 -> [::1]:57556). (NETWORK_ERROR), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::NetException::NetException(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&) @ 0x000000000fd50fb5 3. /build/src/IO/WriteBufferFromPocoSocket.cpp:171: DB::WriteBufferFromPocoSocket::nextImpl() @ 0x000000000fd525a7 4. /build/src/Server/HTTP/HTTPServerResponse.h:197: DB::HTTPWriteBuffer::nextImplChunked() @ 0x000000001690f354 5. /build/src/Server/HTTP/HTTPServerResponse.h:166: DB::WriteBufferFromHTTPServerResponse::nextImpl() @ 0x000000001690d334 6. /build/src/IO/WriteBuffer.h:53: DB::WriteBuffer::next() @ 0x000000000a0755be 7. /build/src/IO/WriteBuffer.h:127: DB::WriteBufferFromHTTPServerResponse::finalizeImpl() @ 0x000000001690da5f 8. /build/src/IO/WriteBuffer.cpp:95: DB::WriteBuffer::finalize() @ 0x000000000fc86a10 9. /build/src/Server/HTTP/WriteBufferFromHTTPServerResponse.cpp:284: DB::WriteBufferFromHTTPServerResponse::cancelWithException(DB::HTTPServerRequest&, int, String const&, DB::WriteBuffer*) @ 0x000000001690dfb2 10. /build/src/Server/HTTPHandler.cpp:664: DB::HTTPHandler::trySendExceptionToClient(int, String const&, DB::HTTPServerRequest&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&) @ 0x000000001686f62e 11. /build/src/Server/HTTPHandler.cpp:771: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x0000000016871a63 12. /build/src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x0000000016907e99 13. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 14. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 16. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 17. ? @ 0x00007fbc6213eac3 18. ? @ 0x00007fbc621d0850 (version 25.3.6.10636.altinitytest (altinity build)) 2025.07.28 11:53:40.316704 [ 17611 ] {a088bd64-d334-409c-b917-34b3b34710b5} executeQuery: Code: 16. DB::Exception: No such column arr_v2 in table test_ixw674u7.t_rename_alter (0f1b84ac-c444-44d8-9e20-952b7b41ef44). (NO_SUCH_COLUMN_IN_TABLE) (version 25.3.6.10636.altinitytest (altinity build)) (from [::1]:40570) (comment: 03352_concurrent_rename_alter.sh) (query 1, line 1) (in query: INSERT INTO t_rename_alter (id, dt, arr_v2) SELECT 1, now(), [(now(), 1, 'a', 'b', 'c')]), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x000000000a6a1e2b 4. /build/src/Interpreters/InterpreterInsertQuery.cpp:258: DB::InterpreterInsertQuery::getSampleBlockImpl(std::vector> const&, std::shared_ptr const&, std::shared_ptr const&, bool, bool) @ 0x000000001492cf06 5. /build/src/Interpreters/InterpreterInsertQuery.cpp:200: DB::InterpreterInsertQuery::getSampleBlock(DB::ASTInsertQuery const&, std::shared_ptr const&, std::shared_ptr const&, std::shared_ptr, bool, bool) @ 0x000000001492c400 6. /build/src/Interpreters/InterpreterInsertQuery.cpp:838: DB::InterpreterInsertQuery::execute() @ 0x0000000014933ae7 7. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88dc9 8. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 9. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 10. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 11. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 12. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 13. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 14. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 15. ? @ 0x00007fbc6213eac3 16. ? @ 0x00007fbc621d0850 2025.07.28 11:53:40.336393 [ 17611 ] {} TCPHandler: Code: 16. DB::Exception: No such column arr_v2 in table test_ixw674u7.t_rename_alter (0f1b84ac-c444-44d8-9e20-952b7b41ef44). (NO_SUCH_COLUMN_IN_TABLE), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x000000000a6a1e2b 4. /build/src/Interpreters/InterpreterInsertQuery.cpp:258: DB::InterpreterInsertQuery::getSampleBlockImpl(std::vector> const&, std::shared_ptr const&, std::shared_ptr const&, bool, bool) @ 0x000000001492cf06 5. /build/src/Interpreters/InterpreterInsertQuery.cpp:200: DB::InterpreterInsertQuery::getSampleBlock(DB::ASTInsertQuery const&, std::shared_ptr const&, std::shared_ptr const&, std::shared_ptr, bool, bool) @ 0x000000001492c400 6. /build/src/Interpreters/InterpreterInsertQuery.cpp:838: DB::InterpreterInsertQuery::execute() @ 0x0000000014933ae7 7. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88dc9 8. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 9. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 10. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 11. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 12. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 13. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 14. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 15. ? @ 0x00007fbc6213eac3 16. ? @ 0x00007fbc621d0850 2025.07.28 11:53:40.344251 [ 5879 ] {70f0968a-7c53-4fba-bd82-918761e15e53} executeQuery: Code: 43. DB::Exception: A value of illegal type was provided as 1st argument 'year' to function 'makeDate32'. Expected: Number, got: String: In scope SELECT makeDate32('1980', '10', '20'). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.6.10636.altinitytest (altinity build)) (from [::1]:40084) (comment: 02243_make_date32.sql) (query 57, line 62) (in query: select makeDate32('1980', '10', '20');), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: 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&&) @ 0x0000000012da74d9 4. /build/src/Functions/FunctionHelpers.cpp:130: DB::(anonymous namespace)::validateArgumentsImpl(DB::IFunction const&, std::vector> const&, unsigned long, std::vector> const&) @ 0x0000000012da5b15 5. /build/src/Functions/FunctionHelpers.cpp:192: DB::validateFunctionArguments(DB::IFunction const&, std::vector> const&, std::vector> const&, std::vector> const&) @ 0x0000000012da54fb 6. /build/src/Functions/makeDate.cpp:91: DB::(anonymous namespace)::FunctionMakeDate::getReturnTypeImpl(std::vector> const&) const @ 0x000000000cf7c834 7. /build/src/Functions/IFunction.cpp:645: DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x0000000012d96b0c 8. /build/src/Functions/IFunction.cpp:577: DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x0000000012d9669c 9. /build/src/Functions/IFunction.cpp:606: DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x0000000012d96edc 10. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3544: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000014033cc9 11. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3838: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000014019a9e 12. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3980: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000014018e31 13. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:4304: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000014042fa7 14. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5605: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000014013749 15. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000140127f9 16. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000014011fce 17. /build/src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000001406ce8a 18. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000014973b42 19. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000001497268d 20. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000014974d24 21. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001492924b 22. /build/src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88641 23. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 24. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 25. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 26. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 27. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 28. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 29. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 30. ? @ 0x00007fbc6213eac3 31. ? @ 0x00007fbc621d0850 2025.07.28 11:53:40.348804 [ 5879 ] {} TCPHandler: Code: 43. DB::Exception: A value of illegal type was provided as 1st argument 'year' to function 'makeDate32'. Expected: Number, got: String: In scope SELECT makeDate32('1980', '10', '20'). (ILLEGAL_TYPE_OF_ARGUMENT), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: 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&&) @ 0x0000000012da74d9 4. /build/src/Functions/FunctionHelpers.cpp:130: DB::(anonymous namespace)::validateArgumentsImpl(DB::IFunction const&, std::vector> const&, unsigned long, std::vector> const&) @ 0x0000000012da5b15 5. /build/src/Functions/FunctionHelpers.cpp:192: DB::validateFunctionArguments(DB::IFunction const&, std::vector> const&, std::vector> const&, std::vector> const&) @ 0x0000000012da54fb 6. /build/src/Functions/makeDate.cpp:91: DB::(anonymous namespace)::FunctionMakeDate::getReturnTypeImpl(std::vector> const&) const @ 0x000000000cf7c834 7. /build/src/Functions/IFunction.cpp:645: DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x0000000012d96b0c 8. /build/src/Functions/IFunction.cpp:577: DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x0000000012d9669c 9. /build/src/Functions/IFunction.cpp:606: DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x0000000012d96edc 10. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3544: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000014033cc9 11. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3838: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000014019a9e 12. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3980: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000014018e31 13. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:4304: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000014042fa7 14. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5605: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000014013749 15. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000140127f9 16. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000014011fce 17. /build/src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000001406ce8a 18. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000014973b42 19. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000001497268d 20. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000014974d24 21. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001492924b 22. /build/src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88641 23. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 24. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 25. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 26. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 27. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 28. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 29. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 30. ? @ 0x00007fbc6213eac3 31. ? @ 0x00007fbc621d0850 2025.07.28 11:53:40.398518 [ 5951 ] {4c08ab97-256e-418e-9be8-d75d1565a312} executeQuery: Code: 16. DB::Exception: No such column arr_v2 in table test_ixw674u7.t_rename_alter (0f1b84ac-c444-44d8-9e20-952b7b41ef44). (NO_SUCH_COLUMN_IN_TABLE) (version 25.3.6.10636.altinitytest (altinity build)) (from [::1]:40594) (comment: 03352_concurrent_rename_alter.sh) (query 1, line 1) (in query: INSERT INTO t_rename_alter (id, dt, arr_v2) SELECT 1, now(), [(now(), 1, 'a', 'b', 'c')]), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x000000000a6a1e2b 4. /build/src/Interpreters/InterpreterInsertQuery.cpp:258: DB::InterpreterInsertQuery::getSampleBlockImpl(std::vector> const&, std::shared_ptr const&, std::shared_ptr const&, bool, bool) @ 0x000000001492cf06 5. /build/src/Interpreters/InterpreterInsertQuery.cpp:200: DB::InterpreterInsertQuery::getSampleBlock(DB::ASTInsertQuery const&, std::shared_ptr const&, std::shared_ptr const&, std::shared_ptr, bool, bool) @ 0x000000001492c400 6. /build/src/Interpreters/InterpreterInsertQuery.cpp:838: DB::InterpreterInsertQuery::execute() @ 0x0000000014933ae7 7. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88dc9 8. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 9. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 10. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 11. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 12. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 13. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 14. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 15. ? @ 0x00007fbc6213eac3 16. ? @ 0x00007fbc621d0850 2025.07.28 11:53:40.416238 [ 5951 ] {} TCPHandler: Code: 16. DB::Exception: No such column arr_v2 in table test_ixw674u7.t_rename_alter (0f1b84ac-c444-44d8-9e20-952b7b41ef44). (NO_SUCH_COLUMN_IN_TABLE), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x000000000a6a1e2b 4. /build/src/Interpreters/InterpreterInsertQuery.cpp:258: DB::InterpreterInsertQuery::getSampleBlockImpl(std::vector> const&, std::shared_ptr const&, std::shared_ptr const&, bool, bool) @ 0x000000001492cf06 5. /build/src/Interpreters/InterpreterInsertQuery.cpp:200: DB::InterpreterInsertQuery::getSampleBlock(DB::ASTInsertQuery const&, std::shared_ptr const&, std::shared_ptr const&, std::shared_ptr, bool, bool) @ 0x000000001492c400 6. /build/src/Interpreters/InterpreterInsertQuery.cpp:838: DB::InterpreterInsertQuery::execute() @ 0x0000000014933ae7 7. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88dc9 8. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 9. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 10. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 11. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 12. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 13. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 14. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 15. ? @ 0x00007fbc6213eac3 16. ? @ 0x00007fbc621d0850 2025.07.28 11:53:40.418449 [ 4900 ] {} 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. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Access/AccessControl.cpp:646: DB::AccessControl::authenticate(DB::Credentials const&, Poco::Net::IPAddress const&, DB::ClientInfo const&) const @ 0x0000000013727552 4. /build/src/Interpreters/Session.cpp:371: DB::Session::authenticate(DB::Credentials const&, Poco::Net::SocketAddress const&, std::vector> const&) @ 0x0000000014a6dd4d 5. /build/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) @ 0x0000000016910eed 6. /build/src/Server/HTTPHandler.cpp:208: DB::HTTPHandler::authenticateUser(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&) @ 0x000000001686a6b6 7. /build/src/Server/HTTPHandler.cpp:224: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000001686aaa7 8. /build/src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x0000000016870807 9. /build/src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x0000000016907e99 10. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 11. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 12. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 13. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 14. ? @ 0x00007fbc6213eac3 15. ? @ 0x00007fbc621d0850 (version 25.3.6.10636.altinitytest (altinity build)) 2025.07.28 11:53:40.436807 [ 17210 ] {69711036-6141-4b48-92c6-926f1ee2d798} executeQuery: Code: 16. DB::Exception: No such column arr_v2 in table test_ixw674u7.t_rename_alter (0f1b84ac-c444-44d8-9e20-952b7b41ef44). (NO_SUCH_COLUMN_IN_TABLE) (version 25.3.6.10636.altinitytest (altinity build)) (from [::1]:40572) (comment: 03352_concurrent_rename_alter.sh) (query 1, line 1) (in query: INSERT INTO t_rename_alter (id, dt, arr_v2) SELECT 1, now(), [(now(), 1, 'a', 'b', 'c')]), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x000000000a6a1e2b 4. /build/src/Interpreters/InterpreterInsertQuery.cpp:258: DB::InterpreterInsertQuery::getSampleBlockImpl(std::vector> const&, std::shared_ptr const&, std::shared_ptr const&, bool, bool) @ 0x000000001492cf06 5. /build/src/Interpreters/InterpreterInsertQuery.cpp:200: DB::InterpreterInsertQuery::getSampleBlock(DB::ASTInsertQuery const&, std::shared_ptr const&, std::shared_ptr const&, std::shared_ptr, bool, bool) @ 0x000000001492c400 6. /build/src/Interpreters/InterpreterInsertQuery.cpp:838: DB::InterpreterInsertQuery::execute() @ 0x0000000014933ae7 7. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88dc9 8. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 9. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 10. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 11. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 12. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 13. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 14. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 15. ? @ 0x00007fbc6213eac3 16. ? @ 0x00007fbc621d0850 2025.07.28 11:53:40.448479 [ 17210 ] {} TCPHandler: Code: 16. DB::Exception: No such column arr_v2 in table test_ixw674u7.t_rename_alter (0f1b84ac-c444-44d8-9e20-952b7b41ef44). (NO_SUCH_COLUMN_IN_TABLE), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x000000000a6a1e2b 4. /build/src/Interpreters/InterpreterInsertQuery.cpp:258: DB::InterpreterInsertQuery::getSampleBlockImpl(std::vector> const&, std::shared_ptr const&, std::shared_ptr const&, bool, bool) @ 0x000000001492cf06 5. /build/src/Interpreters/InterpreterInsertQuery.cpp:200: DB::InterpreterInsertQuery::getSampleBlock(DB::ASTInsertQuery const&, std::shared_ptr const&, std::shared_ptr const&, std::shared_ptr, bool, bool) @ 0x000000001492c400 6. /build/src/Interpreters/InterpreterInsertQuery.cpp:838: DB::InterpreterInsertQuery::execute() @ 0x0000000014933ae7 7. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88dc9 8. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 9. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 10. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 11. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 12. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 13. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 14. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 15. ? @ 0x00007fbc6213eac3 16. ? @ 0x00007fbc621d0850 2025.07.28 11:53:40.503139 [ 5879 ] {c68cfa29-b799-4d43-b06e-f115625daa08} executeQuery: Code: 43. DB::Exception: A value of illegal type was provided as 1st argument 'year' to function 'makeDate32'. Expected: Number, got: String: In scope SELECT makeDate32('-1980', 3, 17). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.6.10636.altinitytest (altinity build)) (from [::1]:40084) (comment: 02243_make_date32.sql) (query 58, line 63) (in query: select makeDate32('-1980', 3, 17);), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: 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&&) @ 0x0000000012da74d9 4. /build/src/Functions/FunctionHelpers.cpp:130: DB::(anonymous namespace)::validateArgumentsImpl(DB::IFunction const&, std::vector> const&, unsigned long, std::vector> const&) @ 0x0000000012da5b15 5. /build/src/Functions/FunctionHelpers.cpp:192: DB::validateFunctionArguments(DB::IFunction const&, std::vector> const&, std::vector> const&, std::vector> const&) @ 0x0000000012da54fb 6. /build/src/Functions/makeDate.cpp:91: DB::(anonymous namespace)::FunctionMakeDate::getReturnTypeImpl(std::vector> const&) const @ 0x000000000cf7c834 7. /build/src/Functions/IFunction.cpp:645: DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x0000000012d96b0c 8. /build/src/Functions/IFunction.cpp:577: DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x0000000012d9669c 9. /build/src/Functions/IFunction.cpp:606: DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x0000000012d96edc 10. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3544: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000014033cc9 11. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3838: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000014019a9e 12. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3980: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000014018e31 13. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:4304: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000014042fa7 14. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5605: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000014013749 15. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000140127f9 16. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000014011fce 17. /build/src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000001406ce8a 18. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000014973b42 19. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000001497268d 20. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000014974d24 21. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001492924b 22. /build/src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88641 23. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 24. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 25. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 26. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 27. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 28. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 29. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 30. ? @ 0x00007fbc6213eac3 31. ? @ 0x00007fbc621d0850 2025.07.28 11:53:40.525476 [ 7625 ] {6db84586-ec91-4c2e-b867-21d72538a159} executeQuery: Code: 16. DB::Exception: No such column arr_v2 in table test_ixw674u7.t_rename_alter (0f1b84ac-c444-44d8-9e20-952b7b41ef44). (NO_SUCH_COLUMN_IN_TABLE) (version 25.3.6.10636.altinitytest (altinity build)) (from [::1]:40638) (comment: 03352_concurrent_rename_alter.sh) (query 1, line 1) (in query: INSERT INTO t_rename_alter (id, dt, arr_v2) SELECT 1, now(), [(now(), 1, 'a', 'b', 'c')]), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x000000000a6a1e2b 4. /build/src/Interpreters/InterpreterInsertQuery.cpp:258: DB::InterpreterInsertQuery::getSampleBlockImpl(std::vector> const&, std::shared_ptr const&, std::shared_ptr const&, bool, bool) @ 0x000000001492cf06 5. /build/src/Interpreters/InterpreterInsertQuery.cpp:200: DB::InterpreterInsertQuery::getSampleBlock(DB::ASTInsertQuery const&, std::shared_ptr const&, std::shared_ptr const&, std::shared_ptr, bool, bool) @ 0x000000001492c400 6. /build/src/Interpreters/InterpreterInsertQuery.cpp:838: DB::InterpreterInsertQuery::execute() @ 0x0000000014933ae7 7. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88dc9 8. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 9. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 10. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 11. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 12. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 13. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 14. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 15. ? @ 0x00007fbc6213eac3 16. ? @ 0x00007fbc621d0850 2025.07.28 11:53:40.581028 [ 5879 ] {} TCPHandler: Code: 43. DB::Exception: A value of illegal type was provided as 1st argument 'year' to function 'makeDate32'. Expected: Number, got: String: In scope SELECT makeDate32('-1980', 3, 17). (ILLEGAL_TYPE_OF_ARGUMENT), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: 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&&) @ 0x0000000012da74d9 4. /build/src/Functions/FunctionHelpers.cpp:130: DB::(anonymous namespace)::validateArgumentsImpl(DB::IFunction const&, std::vector> const&, unsigned long, std::vector> const&) @ 0x0000000012da5b15 5. /build/src/Functions/FunctionHelpers.cpp:192: DB::validateFunctionArguments(DB::IFunction const&, std::vector> const&, std::vector> const&, std::vector> const&) @ 0x0000000012da54fb 6. /build/src/Functions/makeDate.cpp:91: DB::(anonymous namespace)::FunctionMakeDate::getReturnTypeImpl(std::vector> const&) const @ 0x000000000cf7c834 7. /build/src/Functions/IFunction.cpp:645: DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x0000000012d96b0c 8. /build/src/Functions/IFunction.cpp:577: DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x0000000012d9669c 9. /build/src/Functions/IFunction.cpp:606: DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x0000000012d96edc 10. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3544: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000014033cc9 11. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3838: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000014019a9e 12. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3980: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000014018e31 13. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:4304: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000014042fa7 14. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5605: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000014013749 15. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000140127f9 16. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000014011fce 17. /build/src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000001406ce8a 18. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000014973b42 19. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000001497268d 20. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000014974d24 21. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001492924b 22. /build/src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88641 23. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 24. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 25. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 26. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 27. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 28. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 29. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 30. ? @ 0x00007fbc6213eac3 31. ? @ 0x00007fbc621d0850 2025.07.28 11:53:40.587902 [ 7625 ] {} TCPHandler: Code: 16. DB::Exception: No such column arr_v2 in table test_ixw674u7.t_rename_alter (0f1b84ac-c444-44d8-9e20-952b7b41ef44). (NO_SUCH_COLUMN_IN_TABLE), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x000000000a6a1e2b 4. /build/src/Interpreters/InterpreterInsertQuery.cpp:258: DB::InterpreterInsertQuery::getSampleBlockImpl(std::vector> const&, std::shared_ptr const&, std::shared_ptr const&, bool, bool) @ 0x000000001492cf06 5. /build/src/Interpreters/InterpreterInsertQuery.cpp:200: DB::InterpreterInsertQuery::getSampleBlock(DB::ASTInsertQuery const&, std::shared_ptr const&, std::shared_ptr const&, std::shared_ptr, bool, bool) @ 0x000000001492c400 6. /build/src/Interpreters/InterpreterInsertQuery.cpp:838: DB::InterpreterInsertQuery::execute() @ 0x0000000014933ae7 7. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88dc9 8. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 9. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 10. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 11. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 12. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 13. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 14. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 15. ? @ 0x00007fbc6213eac3 16. ? @ 0x00007fbc621d0850 2025.07.28 11:53:40.602378 [ 4900 ] {} 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. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Access/AccessControl.cpp:646: DB::AccessControl::authenticate(DB::Credentials const&, Poco::Net::IPAddress const&, DB::ClientInfo const&) const @ 0x0000000013727552 4. /build/src/Interpreters/Session.cpp:371: DB::Session::authenticate(DB::Credentials const&, Poco::Net::SocketAddress const&, std::vector> const&) @ 0x0000000014a6dd4d 5. /build/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) @ 0x0000000016910eed 6. /build/src/Server/HTTPHandler.cpp:208: DB::HTTPHandler::authenticateUser(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&) @ 0x000000001686a6b6 7. /build/src/Server/HTTPHandler.cpp:224: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000001686aaa7 8. /build/src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x0000000016870807 9. /build/src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x0000000016907e99 10. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 11. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 12. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 13. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 14. ? @ 0x00007fbc6213eac3 15. ? @ 0x00007fbc621d0850 (version 25.3.6.10636.altinitytest (altinity build)) 2025.07.28 11:53:40.700201 [ 17208 ] {14d17779-e753-4198-a9a3-0a3f3874b643} executeQuery: Code: 16. DB::Exception: No such column arr_v2 in table test_ixw674u7.t_rename_alter (0f1b84ac-c444-44d8-9e20-952b7b41ef44). (NO_SUCH_COLUMN_IN_TABLE) (version 25.3.6.10636.altinitytest (altinity build)) (from [::1]:40652) (comment: 03352_concurrent_rename_alter.sh) (query 1, line 1) (in query: INSERT INTO t_rename_alter (id, dt, arr_v2) SELECT 1, now(), [(now(), 1, 'a', 'b', 'c')]), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x000000000a6a1e2b 4. /build/src/Interpreters/InterpreterInsertQuery.cpp:258: DB::InterpreterInsertQuery::getSampleBlockImpl(std::vector> const&, std::shared_ptr const&, std::shared_ptr const&, bool, bool) @ 0x000000001492cf06 5. /build/src/Interpreters/InterpreterInsertQuery.cpp:200: DB::InterpreterInsertQuery::getSampleBlock(DB::ASTInsertQuery const&, std::shared_ptr const&, std::shared_ptr const&, std::shared_ptr, bool, bool) @ 0x000000001492c400 6. /build/src/Interpreters/InterpreterInsertQuery.cpp:838: DB::InterpreterInsertQuery::execute() @ 0x0000000014933ae7 7. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88dc9 8. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 9. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 10. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 11. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 12. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 13. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 14. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 15. ? @ 0x00007fbc6213eac3 16. ? @ 0x00007fbc621d0850 2025.07.28 11:53:40.711773 [ 5879 ] {bf519e35-b734-4d77-b963-161694466575} executeQuery: Code: 43. DB::Exception: A value of illegal type was provided as 1st argument 'year' to function 'makeDate32'. Expected: Number, got: String: In scope SELECT makeDate32('aa', 3, 24). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.6.10636.altinitytest (altinity build)) (from [::1]:40084) (comment: 02243_make_date32.sql) (query 59, line 65) (in query: select makeDate32('aa', 3, 24);), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: 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&&) @ 0x0000000012da74d9 4. /build/src/Functions/FunctionHelpers.cpp:130: DB::(anonymous namespace)::validateArgumentsImpl(DB::IFunction const&, std::vector> const&, unsigned long, std::vector> const&) @ 0x0000000012da5b15 5. /build/src/Functions/FunctionHelpers.cpp:192: DB::validateFunctionArguments(DB::IFunction const&, std::vector> const&, std::vector> const&, std::vector> const&) @ 0x0000000012da54fb 6. /build/src/Functions/makeDate.cpp:91: DB::(anonymous namespace)::FunctionMakeDate::getReturnTypeImpl(std::vector> const&) const @ 0x000000000cf7c834 7. /build/src/Functions/IFunction.cpp:645: DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x0000000012d96b0c 8. /build/src/Functions/IFunction.cpp:577: DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x0000000012d9669c 9. /build/src/Functions/IFunction.cpp:606: DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x0000000012d96edc 10. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3544: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000014033cc9 11. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3838: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000014019a9e 12. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3980: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000014018e31 13. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:4304: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000014042fa7 14. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5605: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000014013749 15. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000140127f9 16. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000014011fce 17. /build/src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000001406ce8a 18. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000014973b42 19. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000001497268d 20. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000014974d24 21. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001492924b 22. /build/src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88641 23. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 24. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 25. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 26. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 27. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 28. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 29. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 30. ? @ 0x00007fbc6213eac3 31. ? @ 0x00007fbc621d0850 2025.07.28 11:53:40.714167 [ 12807 ] {a024b44f-0a54-43ae-8bda-0cdca6b35ca0} 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.6.10636.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.6.10636.altinitytest (altinity build)) (from [::1]:34600) (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. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.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 const&, int&&, String const&, unsigned long&&, String const&) @ 0x000000000feda8d9 4. /build/src/IO/HTTPCommon.cpp:104: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x000000000feda6e2 5. /build/src/IO/HTTPCommon.cpp:93: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x000000000feda537 6. /build/src/IO/ReadWriteBufferFromHTTP.cpp:277: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x000000001184a4c4 7. /build/src/IO/ReadWriteBufferFromHTTP.cpp:285: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x000000001184a615 8. /build/src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x000000001184ae59 9. /build/src/IO/ReadWriteBufferFromHTTP.cpp:472: void std::__function::__policy_invoker::__call_impl[abi:se190107]>(std::__function::__policy_storage const*) @ 0x000000001184cedd 10. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001184858b 11. /build/src/IO/ReadWriteBufferFromHTTP.cpp:465: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x000000001184bf0b 12. /build/src/IO/ReadBuffer.h:60: DB::ReadBuffer::next() @ 0x000000000a148c7b 13. /build/src/IO/ReadBuffer.h:96: DB::LineAsStringRowInputFormat::readRow(std::vector::mutable_ptr, std::allocator::mutable_ptr>>&, DB::RowReadExtension&) @ 0x0000000016ad8f2d 14. /build/src/Processors/Formats/IRowInputFormat.cpp:143: DB::IRowInputFormat::read() @ 0x0000000016a1fc72 15. /build/src/Processors/Formats/IInputFormat.cpp:19: DB::IInputFormat::generate() @ 0x00000000169c5536 16. /build/src/Processors/ISource.cpp:139: DB::ISource::tryGenerate() @ 0x00000000169a24fa 17. /build/src/Processors/ISource.cpp:108: DB::ISource::work() @ 0x00000000169a21e7 18. /build/src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x00000000169bd00f 19. /build/src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x00000000169b2105 20. /build/src/Processors/Executors/PipelineExecutor.cpp:170: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x00000000169b16a7 21. /build/src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x00000000169c081c 22. /build/src/Storages/StorageURL.cpp:467: DB::StorageURLSource::generate() @ 0x000000001601f496 23. /build/src/Processors/ISource.cpp:139: DB::ISource::tryGenerate() @ 0x00000000169a24fa 24. /build/src/Processors/ISource.cpp:108: DB::ISource::work() @ 0x00000000169a21e7 25. /build/src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x00000000169bd00f 26. /build/src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x00000000169b2105 27. /build/src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeSingleThread(unsigned long) @ 0x00000000169b23be 28. /build/src/Processors/Executors/PipelineExecutor.cpp:454: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x00000000169b0be7 29. /build/src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x00000000169b03f4 30. /build/src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:se190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169bfeab 31. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc3d92 2025.07.28 11:53:40.715561 [ 3967 ] {} test_13.rmt2 (7f9b740d-015c-470e-8cc6-8ba33be0dc63): auto DB::StorageReplicatedMergeTree::processQueueEntry(ReplicatedMergeTreeQueue::SelectedEntryPtr)::(anonymous class)::operator()(LogEntryPtr &) const: Code: 86. DB::HTTPException: Received error from remote server http://146b4357c08d:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Ftest%2F01165%2Ftest_13%2Frmt%2Freplicas%2F1&part=20250728_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.6.10636.altinitytest (altinity build)) '. (RECEIVED_ERROR_FROM_REMOTE_IO_SERVER), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.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 const&, int&&, String const&, unsigned long&&, String const&) @ 0x000000000feda8d9 4. /build/src/IO/HTTPCommon.cpp:104: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x000000000feda6e2 5. /build/src/IO/HTTPCommon.cpp:93: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x000000000feda537 6. /build/src/IO/ReadWriteBufferFromHTTP.cpp:277: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x000000001184a4c4 7. /build/src/IO/ReadWriteBufferFromHTTP.cpp:285: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x000000001184a615 8. /build/src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x000000001184ae59 9. /build/src/IO/ReadWriteBufferFromHTTP.cpp:472: void std::__function::__policy_invoker::__call_impl[abi:se190107]>(std::__function::__policy_storage const*) @ 0x000000001184cedd 10. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001184858b 11. /build/src/IO/ReadWriteBufferFromHTTP.cpp:465: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x000000001184bf0b 12. /build/src/IO/ReadBuffer.h:60: DB::ReadBuffer::next() @ 0x000000000a148c7b 13. /build/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) @ 0x0000000011849fb2 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]>&)>&, 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&) @ 0x0000000011841980 15. /build/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) @ 0x000000001621208e 16. /build/src/Storages/StorageReplicatedMergeTree.cpp:5228: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl[abi:se190107] const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000015f9a5fe 17. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000015ed8bfd 18. /build/src/Storages/StorageReplicatedMergeTree.cpp:2514: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x0000000015ec9aab 19. /build/src/Storages/StorageReplicatedMergeTree.cpp:2349: DB::StorageReplicatedMergeTree::executeLogEntry(DB::ReplicatedMergeTreeLogEntry&) @ 0x0000000015eba91b 20. /build/src/Storages/StorageReplicatedMergeTree.cpp:3876: bool std::__function::__policy_invoker&)>::__call_impl[abi:se190107])::$_1, bool (std::shared_ptr&)>>(std::__function::__policy_storage const*, std::shared_ptr&) @ 0x0000000015f9837e 21. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000165d6fc3 22. /build/src/Storages/StorageReplicatedMergeTree.cpp:3872: DB::StorageReplicatedMergeTree::processQueueEntry(std::shared_ptr) @ 0x0000000015efc18a 23. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001624c1b2 24. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000162f9c70 25. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x00000000162fa55a 26. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc6653 27. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000000fccc4c3 28. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc3d92 29. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fcca080 30. ? @ 0x00007fbc6213eac3 31. ? @ 0x00007fbc621d0850 (version 25.3.6.10636.altinitytest (altinity build)) 2025.07.28 11:53:40.719323 [ 17208 ] {} TCPHandler: Code: 16. DB::Exception: No such column arr_v2 in table test_ixw674u7.t_rename_alter (0f1b84ac-c444-44d8-9e20-952b7b41ef44). (NO_SUCH_COLUMN_IN_TABLE), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x000000000a6a1e2b 4. /build/src/Interpreters/InterpreterInsertQuery.cpp:258: DB::InterpreterInsertQuery::getSampleBlockImpl(std::vector> const&, std::shared_ptr const&, std::shared_ptr const&, bool, bool) @ 0x000000001492cf06 5. /build/src/Interpreters/InterpreterInsertQuery.cpp:200: DB::InterpreterInsertQuery::getSampleBlock(DB::ASTInsertQuery const&, std::shared_ptr const&, std::shared_ptr const&, std::shared_ptr, bool, bool) @ 0x000000001492c400 6. /build/src/Interpreters/InterpreterInsertQuery.cpp:838: DB::InterpreterInsertQuery::execute() @ 0x0000000014933ae7 7. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88dc9 8. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 9. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 10. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 11. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 12. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 13. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 14. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 15. ? @ 0x00007fbc6213eac3 16. ? @ 0x00007fbc621d0850 2025.07.28 11:53:40.719707 [ 5879 ] {} TCPHandler: Code: 43. DB::Exception: A value of illegal type was provided as 1st argument 'year' to function 'makeDate32'. Expected: Number, got: String: In scope SELECT makeDate32('aa', 3, 24). (ILLEGAL_TYPE_OF_ARGUMENT), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: 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&&) @ 0x0000000012da74d9 4. /build/src/Functions/FunctionHelpers.cpp:130: DB::(anonymous namespace)::validateArgumentsImpl(DB::IFunction const&, std::vector> const&, unsigned long, std::vector> const&) @ 0x0000000012da5b15 5. /build/src/Functions/FunctionHelpers.cpp:192: DB::validateFunctionArguments(DB::IFunction const&, std::vector> const&, std::vector> const&, std::vector> const&) @ 0x0000000012da54fb 6. /build/src/Functions/makeDate.cpp:91: DB::(anonymous namespace)::FunctionMakeDate::getReturnTypeImpl(std::vector> const&) const @ 0x000000000cf7c834 7. /build/src/Functions/IFunction.cpp:645: DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x0000000012d96b0c 8. /build/src/Functions/IFunction.cpp:577: DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x0000000012d9669c 9. /build/src/Functions/IFunction.cpp:606: DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x0000000012d96edc 10. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3544: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000014033cc9 11. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3838: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000014019a9e 12. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3980: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000014018e31 13. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:4304: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000014042fa7 14. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5605: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000014013749 15. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000140127f9 16. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000014011fce 17. /build/src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000001406ce8a 18. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000014973b42 19. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000001497268d 20. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000014974d24 21. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001492924b 22. /build/src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88641 23. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 24. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 25. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 26. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 27. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 28. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 29. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 30. ? @ 0x00007fbc6213eac3 31. ? @ 0x00007fbc621d0850 2025.07.28 11:53:40.736506 [ 12807 ] {} 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.6.10636.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. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.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 const&, int&&, String const&, unsigned long&&, String const&) @ 0x000000000feda8d9 4. /build/src/IO/HTTPCommon.cpp:104: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x000000000feda6e2 5. /build/src/IO/HTTPCommon.cpp:93: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x000000000feda537 6. /build/src/IO/ReadWriteBufferFromHTTP.cpp:277: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x000000001184a4c4 7. /build/src/IO/ReadWriteBufferFromHTTP.cpp:285: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x000000001184a615 8. /build/src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x000000001184ae59 9. /build/src/IO/ReadWriteBufferFromHTTP.cpp:472: void std::__function::__policy_invoker::__call_impl[abi:se190107]>(std::__function::__policy_storage const*) @ 0x000000001184cedd 10. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001184858b 11. /build/src/IO/ReadWriteBufferFromHTTP.cpp:465: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x000000001184bf0b 12. /build/src/IO/ReadBuffer.h:60: DB::ReadBuffer::next() @ 0x000000000a148c7b 13. /build/src/IO/ReadBuffer.h:96: DB::LineAsStringRowInputFormat::readRow(std::vector::mutable_ptr, std::allocator::mutable_ptr>>&, DB::RowReadExtension&) @ 0x0000000016ad8f2d 14. /build/src/Processors/Formats/IRowInputFormat.cpp:143: DB::IRowInputFormat::read() @ 0x0000000016a1fc72 15. /build/src/Processors/Formats/IInputFormat.cpp:19: DB::IInputFormat::generate() @ 0x00000000169c5536 16. /build/src/Processors/ISource.cpp:139: DB::ISource::tryGenerate() @ 0x00000000169a24fa 17. /build/src/Processors/ISource.cpp:108: DB::ISource::work() @ 0x00000000169a21e7 18. /build/src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x00000000169bd00f 19. /build/src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x00000000169b2105 20. /build/src/Processors/Executors/PipelineExecutor.cpp:170: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x00000000169b16a7 21. /build/src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x00000000169c081c 22. /build/src/Storages/StorageURL.cpp:467: DB::StorageURLSource::generate() @ 0x000000001601f496 23. /build/src/Processors/ISource.cpp:139: DB::ISource::tryGenerate() @ 0x00000000169a24fa 24. /build/src/Processors/ISource.cpp:108: DB::ISource::work() @ 0x00000000169a21e7 25. /build/src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x00000000169bd00f 26. /build/src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x00000000169b2105 27. /build/src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeSingleThread(unsigned long) @ 0x00000000169b23be 28. /build/src/Processors/Executors/PipelineExecutor.cpp:454: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x00000000169b0be7 29. /build/src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x00000000169b03f4 30. /build/src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:se190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169bfeab 31. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc3d92 Job's origin stack trace: 0. /build/src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000000fc33b84 1. /build/src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000000fcc2ea7 2. /build/src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fcc535c 3. /build/src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000000fcc584d 4. /build/src/Common/ThreadPool.h:279: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x00000000169bf193 5. /build/src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x00000000169bf518 6. /build/src/Server/TCPHandler.cpp:1237: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x00000000168f1525 7. /build/src/Server/TCPHandler.cpp:678: DB::TCPHandler::runImpl() @ 0x00000000168e68e5 8. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 9. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 10. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 11. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 12. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 13. ? @ 0x00007fbc6213eac3 14. ? @ 0x00007fbc621d0850 2025.07.28 11:53:40.882968 [ 4963 ] {31eb75cf-c830-483a-9066-6b484047b71a} executeQuery: Code: 16. DB::Exception: No such column arr_v2 in table test_ixw674u7.t_rename_alter (0f1b84ac-c444-44d8-9e20-952b7b41ef44). (NO_SUCH_COLUMN_IN_TABLE) (version 25.3.6.10636.altinitytest (altinity build)) (from [::1]:40740) (comment: 03352_concurrent_rename_alter.sh) (query 1, line 1) (in query: INSERT INTO t_rename_alter (id, dt, arr_v2) SELECT 1, now(), [(now(), 1, 'a', 'b', 'c')]), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x000000000a6a1e2b 4. /build/src/Interpreters/InterpreterInsertQuery.cpp:258: DB::InterpreterInsertQuery::getSampleBlockImpl(std::vector> const&, std::shared_ptr const&, std::shared_ptr const&, bool, bool) @ 0x000000001492cf06 5. /build/src/Interpreters/InterpreterInsertQuery.cpp:200: DB::InterpreterInsertQuery::getSampleBlock(DB::ASTInsertQuery const&, std::shared_ptr const&, std::shared_ptr const&, std::shared_ptr, bool, bool) @ 0x000000001492c400 6. /build/src/Interpreters/InterpreterInsertQuery.cpp:838: DB::InterpreterInsertQuery::execute() @ 0x0000000014933ae7 7. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88dc9 8. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 9. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 10. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 11. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 12. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 13. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 14. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 15. ? @ 0x00007fbc6213eac3 16. ? @ 0x00007fbc621d0850 2025.07.28 11:53:40.899070 [ 4963 ] {} TCPHandler: Code: 16. DB::Exception: No such column arr_v2 in table test_ixw674u7.t_rename_alter (0f1b84ac-c444-44d8-9e20-952b7b41ef44). (NO_SUCH_COLUMN_IN_TABLE), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x000000000a6a1e2b 4. /build/src/Interpreters/InterpreterInsertQuery.cpp:258: DB::InterpreterInsertQuery::getSampleBlockImpl(std::vector> const&, std::shared_ptr const&, std::shared_ptr const&, bool, bool) @ 0x000000001492cf06 5. /build/src/Interpreters/InterpreterInsertQuery.cpp:200: DB::InterpreterInsertQuery::getSampleBlock(DB::ASTInsertQuery const&, std::shared_ptr const&, std::shared_ptr const&, std::shared_ptr, bool, bool) @ 0x000000001492c400 6. /build/src/Interpreters/InterpreterInsertQuery.cpp:838: DB::InterpreterInsertQuery::execute() @ 0x0000000014933ae7 7. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88dc9 8. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 9. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 10. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 11. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 12. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 13. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 14. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 15. ? @ 0x00007fbc6213eac3 16. ? @ 0x00007fbc621d0850 2025.07.28 11:53:40.953628 [ 17261 ] {c9aa137e-66c9-4850-aa9c-bda8cb2eeeb3} executeQuery: Code: 16. DB::Exception: No such column arr_v2 in table test_ixw674u7.t_rename_alter (0f1b84ac-c444-44d8-9e20-952b7b41ef44). (NO_SUCH_COLUMN_IN_TABLE) (version 25.3.6.10636.altinitytest (altinity build)) (from [::1]:40790) (comment: 03352_concurrent_rename_alter.sh) (query 1, line 1) (in query: INSERT INTO t_rename_alter (id, dt, arr_v2) SELECT 1, now(), [(now(), 1, 'a', 'b', 'c')]), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x000000000a6a1e2b 4. /build/src/Interpreters/InterpreterInsertQuery.cpp:258: DB::InterpreterInsertQuery::getSampleBlockImpl(std::vector> const&, std::shared_ptr const&, std::shared_ptr const&, bool, bool) @ 0x000000001492cf06 5. /build/src/Interpreters/InterpreterInsertQuery.cpp:200: DB::InterpreterInsertQuery::getSampleBlock(DB::ASTInsertQuery const&, std::shared_ptr const&, std::shared_ptr const&, std::shared_ptr, bool, bool) @ 0x000000001492c400 6. /build/src/Interpreters/InterpreterInsertQuery.cpp:838: DB::InterpreterInsertQuery::execute() @ 0x0000000014933ae7 7. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88dc9 8. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 9. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 10. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 11. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 12. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 13. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 14. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 15. ? @ 0x00007fbc6213eac3 16. ? @ 0x00007fbc621d0850 2025.07.28 11:53:40.964018 [ 17261 ] {} TCPHandler: Code: 16. DB::Exception: No such column arr_v2 in table test_ixw674u7.t_rename_alter (0f1b84ac-c444-44d8-9e20-952b7b41ef44). (NO_SUCH_COLUMN_IN_TABLE), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x000000000a6a1e2b 4. /build/src/Interpreters/InterpreterInsertQuery.cpp:258: DB::InterpreterInsertQuery::getSampleBlockImpl(std::vector> const&, std::shared_ptr const&, std::shared_ptr const&, bool, bool) @ 0x000000001492cf06 5. /build/src/Interpreters/InterpreterInsertQuery.cpp:200: DB::InterpreterInsertQuery::getSampleBlock(DB::ASTInsertQuery const&, std::shared_ptr const&, std::shared_ptr const&, std::shared_ptr, bool, bool) @ 0x000000001492c400 6. /build/src/Interpreters/InterpreterInsertQuery.cpp:838: DB::InterpreterInsertQuery::execute() @ 0x0000000014933ae7 7. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88dc9 8. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 9. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 10. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 11. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 12. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 13. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 14. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 15. ? @ 0x00007fbc6213eac3 16. ? @ 0x00007fbc621d0850 2025.07.28 11:53:41.003234 [ 5879 ] {15f6656f-946f-4891-8cb9-4c7048496222} executeQuery: Code: 43. DB::Exception: A value of illegal type was provided as 2nd argument 'month' to function 'makeDate32'. Expected: Number, got: String: In scope SELECT makeDate32(1994, 'aa', 24). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.6.10636.altinitytest (altinity build)) (from [::1]:40084) (comment: 02243_make_date32.sql) (query 60, line 66) (in query: select makeDate32(1994, 'aa', 24);), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: 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&&) @ 0x0000000012da74d9 4. /build/src/Functions/FunctionHelpers.cpp:130: DB::(anonymous namespace)::validateArgumentsImpl(DB::IFunction const&, std::vector> const&, unsigned long, std::vector> const&) @ 0x0000000012da5b15 5. /build/src/Functions/FunctionHelpers.cpp:192: DB::validateFunctionArguments(DB::IFunction const&, std::vector> const&, std::vector> const&, std::vector> const&) @ 0x0000000012da54fb 6. /build/src/Functions/makeDate.cpp:91: DB::(anonymous namespace)::FunctionMakeDate::getReturnTypeImpl(std::vector> const&) const @ 0x000000000cf7c834 7. /build/src/Functions/IFunction.cpp:645: DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x0000000012d96b0c 8. /build/src/Functions/IFunction.cpp:577: DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x0000000012d9669c 9. /build/src/Functions/IFunction.cpp:606: DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x0000000012d96edc 10. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3544: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000014033cc9 11. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3838: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000014019a9e 12. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3980: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000014018e31 13. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:4304: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000014042fa7 14. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5605: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000014013749 15. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000140127f9 16. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000014011fce 17. /build/src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000001406ce8a 18. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000014973b42 19. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000001497268d 20. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000014974d24 21. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001492924b 22. /build/src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88641 23. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 24. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 25. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 26. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 27. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 28. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 29. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 30. ? @ 0x00007fbc6213eac3 31. ? @ 0x00007fbc621d0850 2025.07.28 11:53:41.003614 [ 4580 ] {d7bfb239-f619-4cd2-80a1-ffe01c22af66} executeQuery: Code: 16. DB::Exception: No such column arr_v2 in table test_ixw674u7.t_rename_alter (0f1b84ac-c444-44d8-9e20-952b7b41ef44). (NO_SUCH_COLUMN_IN_TABLE) (version 25.3.6.10636.altinitytest (altinity build)) (from [::1]:40692) (comment: 03352_concurrent_rename_alter.sh) (query 1, line 1) (in query: INSERT INTO t_rename_alter (id, dt, arr_v2) SELECT 1, now(), [(now(), 1, 'a', 'b', 'c')]), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x000000000a6a1e2b 4. /build/src/Interpreters/InterpreterInsertQuery.cpp:258: DB::InterpreterInsertQuery::getSampleBlockImpl(std::vector> const&, std::shared_ptr const&, std::shared_ptr const&, bool, bool) @ 0x000000001492cf06 5. /build/src/Interpreters/InterpreterInsertQuery.cpp:200: DB::InterpreterInsertQuery::getSampleBlock(DB::ASTInsertQuery const&, std::shared_ptr const&, std::shared_ptr const&, std::shared_ptr, bool, bool) @ 0x000000001492c400 6. /build/src/Interpreters/InterpreterInsertQuery.cpp:838: DB::InterpreterInsertQuery::execute() @ 0x0000000014933ae7 7. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88dc9 8. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 9. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 10. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 11. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 12. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 13. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 14. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 15. ? @ 0x00007fbc6213eac3 16. ? @ 0x00007fbc621d0850 2025.07.28 11:53:41.043461 [ 4580 ] {} TCPHandler: Code: 16. DB::Exception: No such column arr_v2 in table test_ixw674u7.t_rename_alter (0f1b84ac-c444-44d8-9e20-952b7b41ef44). (NO_SUCH_COLUMN_IN_TABLE), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x000000000a6a1e2b 4. /build/src/Interpreters/InterpreterInsertQuery.cpp:258: DB::InterpreterInsertQuery::getSampleBlockImpl(std::vector> const&, std::shared_ptr const&, std::shared_ptr const&, bool, bool) @ 0x000000001492cf06 5. /build/src/Interpreters/InterpreterInsertQuery.cpp:200: DB::InterpreterInsertQuery::getSampleBlock(DB::ASTInsertQuery const&, std::shared_ptr const&, std::shared_ptr const&, std::shared_ptr, bool, bool) @ 0x000000001492c400 6. /build/src/Interpreters/InterpreterInsertQuery.cpp:838: DB::InterpreterInsertQuery::execute() @ 0x0000000014933ae7 7. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88dc9 8. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 9. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 10. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 11. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 12. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 13. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 14. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 15. ? @ 0x00007fbc6213eac3 16. ? @ 0x00007fbc621d0850 2025.07.28 11:53:41.062862 [ 5879 ] {} TCPHandler: Code: 43. DB::Exception: A value of illegal type was provided as 2nd argument 'month' to function 'makeDate32'. Expected: Number, got: String: In scope SELECT makeDate32(1994, 'aa', 24). (ILLEGAL_TYPE_OF_ARGUMENT), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: 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&&) @ 0x0000000012da74d9 4. /build/src/Functions/FunctionHelpers.cpp:130: DB::(anonymous namespace)::validateArgumentsImpl(DB::IFunction const&, std::vector> const&, unsigned long, std::vector> const&) @ 0x0000000012da5b15 5. /build/src/Functions/FunctionHelpers.cpp:192: DB::validateFunctionArguments(DB::IFunction const&, std::vector> const&, std::vector> const&, std::vector> const&) @ 0x0000000012da54fb 6. /build/src/Functions/makeDate.cpp:91: DB::(anonymous namespace)::FunctionMakeDate::getReturnTypeImpl(std::vector> const&) const @ 0x000000000cf7c834 7. /build/src/Functions/IFunction.cpp:645: DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x0000000012d96b0c 8. /build/src/Functions/IFunction.cpp:577: DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x0000000012d9669c 9. /build/src/Functions/IFunction.cpp:606: DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x0000000012d96edc 10. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3544: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000014033cc9 11. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3838: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000014019a9e 12. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3980: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000014018e31 13. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:4304: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000014042fa7 14. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5605: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000014013749 15. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000140127f9 16. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000014011fce 17. /build/src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000001406ce8a 18. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000014973b42 19. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000001497268d 20. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000014974d24 21. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001492924b 22. /build/src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88641 23. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 24. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 25. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 26. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 27. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 28. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 29. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 30. ? @ 0x00007fbc6213eac3 31. ? @ 0x00007fbc621d0850 2025.07.28 11:53:41.121645 [ 4900 ] {} 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. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Access/AccessControl.cpp:646: DB::AccessControl::authenticate(DB::Credentials const&, Poco::Net::IPAddress const&, DB::ClientInfo const&) const @ 0x0000000013727552 4. /build/src/Interpreters/Session.cpp:371: DB::Session::authenticate(DB::Credentials const&, Poco::Net::SocketAddress const&, std::vector> const&) @ 0x0000000014a6dd4d 5. /build/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) @ 0x0000000016910eed 6. /build/src/Server/HTTPHandler.cpp:208: DB::HTTPHandler::authenticateUser(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&) @ 0x000000001686a6b6 7. /build/src/Server/HTTPHandler.cpp:224: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000001686aaa7 8. /build/src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x0000000016870807 9. /build/src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x0000000016907e99 10. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 11. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 12. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 13. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 14. ? @ 0x00007fbc6213eac3 15. ? @ 0x00007fbc621d0850 (version 25.3.6.10636.altinitytest (altinity build)) 2025.07.28 11:53:41.192220 [ 4900 ] {} 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. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Access/AccessControl.cpp:646: DB::AccessControl::authenticate(DB::Credentials const&, Poco::Net::IPAddress const&, DB::ClientInfo const&) const @ 0x0000000013727552 4. /build/src/Interpreters/Session.cpp:371: DB::Session::authenticate(DB::Credentials const&, Poco::Net::SocketAddress const&, std::vector> const&) @ 0x0000000014a6dd4d 5. /build/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) @ 0x0000000016910eed 6. /build/src/Server/HTTPHandler.cpp:208: DB::HTTPHandler::authenticateUser(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&) @ 0x000000001686a6b6 7. /build/src/Server/HTTPHandler.cpp:224: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000001686aaa7 8. /build/src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x0000000016870807 9. /build/src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x0000000016907e99 10. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 11. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 12. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 13. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 14. ? @ 0x00007fbc6213eac3 15. ? @ 0x00007fbc621d0850 (version 25.3.6.10636.altinitytest (altinity build)) 2025.07.28 11:53:41.212593 [ 12807 ] {5a8da41b-d709-431c-a72f-8359cbcef75f} 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.6.10636.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.6.10636.altinitytest (altinity build)) (from [::1]:34600) (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. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.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 const&, int&&, String const&, unsigned long&&, String const&) @ 0x000000000feda8d9 4. /build/src/IO/HTTPCommon.cpp:104: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x000000000feda6e2 5. /build/src/IO/HTTPCommon.cpp:93: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x000000000feda537 6. /build/src/IO/ReadWriteBufferFromHTTP.cpp:277: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x000000001184a4c4 7. /build/src/IO/ReadWriteBufferFromHTTP.cpp:285: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x000000001184a615 8. /build/src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x000000001184ae59 9. /build/src/IO/ReadWriteBufferFromHTTP.cpp:472: void std::__function::__policy_invoker::__call_impl[abi:se190107]>(std::__function::__policy_storage const*) @ 0x000000001184cedd 10. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001184858b 11. /build/src/IO/ReadWriteBufferFromHTTP.cpp:465: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x000000001184bf0b 12. /build/src/IO/ReadBuffer.h:60: DB::ReadBuffer::next() @ 0x000000000a148c7b 13. /build/src/IO/ReadBuffer.h:96: DB::LineAsStringRowInputFormat::readRow(std::vector::mutable_ptr, std::allocator::mutable_ptr>>&, DB::RowReadExtension&) @ 0x0000000016ad8f2d 14. /build/src/Processors/Formats/IRowInputFormat.cpp:143: DB::IRowInputFormat::read() @ 0x0000000016a1fc72 15. /build/src/Processors/Formats/IInputFormat.cpp:19: DB::IInputFormat::generate() @ 0x00000000169c5536 16. /build/src/Processors/ISource.cpp:139: DB::ISource::tryGenerate() @ 0x00000000169a24fa 17. /build/src/Processors/ISource.cpp:108: DB::ISource::work() @ 0x00000000169a21e7 18. /build/src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x00000000169bd00f 19. /build/src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x00000000169b2105 20. /build/src/Processors/Executors/PipelineExecutor.cpp:170: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x00000000169b16a7 21. /build/src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x00000000169c081c 22. /build/src/Storages/StorageURL.cpp:467: DB::StorageURLSource::generate() @ 0x000000001601f496 23. /build/src/Processors/ISource.cpp:139: DB::ISource::tryGenerate() @ 0x00000000169a24fa 24. /build/src/Processors/ISource.cpp:108: DB::ISource::work() @ 0x00000000169a21e7 25. /build/src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x00000000169bd00f 26. /build/src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x00000000169b2105 27. /build/src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeSingleThread(unsigned long) @ 0x00000000169b23be 28. /build/src/Processors/Executors/PipelineExecutor.cpp:454: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x00000000169b0be7 29. /build/src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x00000000169b03f4 30. /build/src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:se190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169bfeab 31. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc3d92 2025.07.28 11:53:41.220827 [ 5879 ] {507242e8-1ab8-4819-af64-4559ea335d9d} executeQuery: Code: 43. DB::Exception: A value of illegal type was provided as 3rd argument 'day' to function 'makeDate32'. Expected: Number, got: String: In scope SELECT makeDate32(1984, 3, 'aa'). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.6.10636.altinitytest (altinity build)) (from [::1]:40084) (comment: 02243_make_date32.sql) (query 61, line 67) (in query: select makeDate32(1984, 3, 'aa');), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: 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&&) @ 0x0000000012da74d9 4. /build/src/Functions/FunctionHelpers.cpp:130: DB::(anonymous namespace)::validateArgumentsImpl(DB::IFunction const&, std::vector> const&, unsigned long, std::vector> const&) @ 0x0000000012da5b15 5. /build/src/Functions/FunctionHelpers.cpp:192: DB::validateFunctionArguments(DB::IFunction const&, std::vector> const&, std::vector> const&, std::vector> const&) @ 0x0000000012da54fb 6. /build/src/Functions/makeDate.cpp:91: DB::(anonymous namespace)::FunctionMakeDate::getReturnTypeImpl(std::vector> const&) const @ 0x000000000cf7c834 7. /build/src/Functions/IFunction.cpp:645: DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x0000000012d96b0c 8. /build/src/Functions/IFunction.cpp:577: DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x0000000012d9669c 9. /build/src/Functions/IFunction.cpp:606: DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x0000000012d96edc 10. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3544: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000014033cc9 11. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3838: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000014019a9e 12. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3980: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000014018e31 13. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:4304: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000014042fa7 14. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5605: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000014013749 15. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000140127f9 16. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000014011fce 17. /build/src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000001406ce8a 18. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000014973b42 19. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000001497268d 20. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000014974d24 21. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001492924b 22. /build/src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88641 23. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 24. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 25. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 26. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 27. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 28. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 29. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 30. ? @ 0x00007fbc6213eac3 31. ? @ 0x00007fbc621d0850 2025.07.28 11:53:41.224070 [ 5879 ] {} TCPHandler: Code: 43. DB::Exception: A value of illegal type was provided as 3rd argument 'day' to function 'makeDate32'. Expected: Number, got: String: In scope SELECT makeDate32(1984, 3, 'aa'). (ILLEGAL_TYPE_OF_ARGUMENT), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: 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&&) @ 0x0000000012da74d9 4. /build/src/Functions/FunctionHelpers.cpp:130: DB::(anonymous namespace)::validateArgumentsImpl(DB::IFunction const&, std::vector> const&, unsigned long, std::vector> const&) @ 0x0000000012da5b15 5. /build/src/Functions/FunctionHelpers.cpp:192: DB::validateFunctionArguments(DB::IFunction const&, std::vector> const&, std::vector> const&, std::vector> const&) @ 0x0000000012da54fb 6. /build/src/Functions/makeDate.cpp:91: DB::(anonymous namespace)::FunctionMakeDate::getReturnTypeImpl(std::vector> const&) const @ 0x000000000cf7c834 7. /build/src/Functions/IFunction.cpp:645: DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x0000000012d96b0c 8. /build/src/Functions/IFunction.cpp:577: DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x0000000012d9669c 9. /build/src/Functions/IFunction.cpp:606: DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x0000000012d96edc 10. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3544: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000014033cc9 11. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3838: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000014019a9e 12. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3980: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000014018e31 13. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:4304: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000014042fa7 14. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5605: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000014013749 15. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000140127f9 16. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000014011fce 17. /build/src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000001406ce8a 18. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000014973b42 19. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000001497268d 20. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000014974d24 21. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001492924b 22. /build/src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88641 23. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 24. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 25. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 26. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 27. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 28. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 29. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 30. ? @ 0x00007fbc6213eac3 31. ? @ 0x00007fbc621d0850 2025.07.28 11:53:41.224314 [ 12807 ] {} 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.6.10636.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. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.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 const&, int&&, String const&, unsigned long&&, String const&) @ 0x000000000feda8d9 4. /build/src/IO/HTTPCommon.cpp:104: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x000000000feda6e2 5. /build/src/IO/HTTPCommon.cpp:93: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x000000000feda537 6. /build/src/IO/ReadWriteBufferFromHTTP.cpp:277: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x000000001184a4c4 7. /build/src/IO/ReadWriteBufferFromHTTP.cpp:285: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x000000001184a615 8. /build/src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x000000001184ae59 9. /build/src/IO/ReadWriteBufferFromHTTP.cpp:472: void std::__function::__policy_invoker::__call_impl[abi:se190107]>(std::__function::__policy_storage const*) @ 0x000000001184cedd 10. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001184858b 11. /build/src/IO/ReadWriteBufferFromHTTP.cpp:465: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x000000001184bf0b 12. /build/src/IO/ReadBuffer.h:60: DB::ReadBuffer::next() @ 0x000000000a148c7b 13. /build/src/IO/ReadBuffer.h:96: DB::LineAsStringRowInputFormat::readRow(std::vector::mutable_ptr, std::allocator::mutable_ptr>>&, DB::RowReadExtension&) @ 0x0000000016ad8f2d 14. /build/src/Processors/Formats/IRowInputFormat.cpp:143: DB::IRowInputFormat::read() @ 0x0000000016a1fc72 15. /build/src/Processors/Formats/IInputFormat.cpp:19: DB::IInputFormat::generate() @ 0x00000000169c5536 16. /build/src/Processors/ISource.cpp:139: DB::ISource::tryGenerate() @ 0x00000000169a24fa 17. /build/src/Processors/ISource.cpp:108: DB::ISource::work() @ 0x00000000169a21e7 18. /build/src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x00000000169bd00f 19. /build/src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x00000000169b2105 20. /build/src/Processors/Executors/PipelineExecutor.cpp:170: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x00000000169b16a7 21. /build/src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x00000000169c081c 22. /build/src/Storages/StorageURL.cpp:467: DB::StorageURLSource::generate() @ 0x000000001601f496 23. /build/src/Processors/ISource.cpp:139: DB::ISource::tryGenerate() @ 0x00000000169a24fa 24. /build/src/Processors/ISource.cpp:108: DB::ISource::work() @ 0x00000000169a21e7 25. /build/src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x00000000169bd00f 26. /build/src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x00000000169b2105 27. /build/src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeSingleThread(unsigned long) @ 0x00000000169b23be 28. /build/src/Processors/Executors/PipelineExecutor.cpp:454: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x00000000169b0be7 29. /build/src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x00000000169b03f4 30. /build/src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:se190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169bfeab 31. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc3d92 Job's origin stack trace: 0. /build/src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000000fc33b84 1. /build/src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000000fcc2ea7 2. /build/src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fcc535c 3. /build/src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000000fcc584d 4. /build/src/Common/ThreadPool.h:279: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x00000000169bf193 5. /build/src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x00000000169bf518 6. /build/src/Server/TCPHandler.cpp:1237: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x00000000168f1525 7. /build/src/Server/TCPHandler.cpp:678: DB::TCPHandler::runImpl() @ 0x00000000168e68e5 8. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 9. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 10. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 11. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 12. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 13. ? @ 0x00007fbc6213eac3 14. ? @ 0x00007fbc621d0850 2025.07.28 11:53:41.471850 [ 3969 ] {} test_13.rmt2 (7f9b740d-015c-470e-8cc6-8ba33be0dc63): auto DB::StorageReplicatedMergeTree::processQueueEntry(ReplicatedMergeTreeQueue::SelectedEntryPtr)::(anonymous class)::operator()(LogEntryPtr &) const: Code: 86. DB::HTTPException: Received error from remote server http://146b4357c08d:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Ftest%2F01165%2Ftest_13%2Frmt%2Freplicas%2F1&part=20250728_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.6.10636.altinitytest (altinity build)) '. (RECEIVED_ERROR_FROM_REMOTE_IO_SERVER), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.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 const&, int&&, String const&, unsigned long&&, String const&) @ 0x000000000feda8d9 4. /build/src/IO/HTTPCommon.cpp:104: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x000000000feda6e2 5. /build/src/IO/HTTPCommon.cpp:93: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x000000000feda537 6. /build/src/IO/ReadWriteBufferFromHTTP.cpp:277: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x000000001184a4c4 7. /build/src/IO/ReadWriteBufferFromHTTP.cpp:285: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x000000001184a615 8. /build/src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x000000001184ae59 9. /build/src/IO/ReadWriteBufferFromHTTP.cpp:472: void std::__function::__policy_invoker::__call_impl[abi:se190107]>(std::__function::__policy_storage const*) @ 0x000000001184cedd 10. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001184858b 11. /build/src/IO/ReadWriteBufferFromHTTP.cpp:465: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x000000001184bf0b 12. /build/src/IO/ReadBuffer.h:60: DB::ReadBuffer::next() @ 0x000000000a148c7b 13. /build/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) @ 0x0000000011849fb2 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]>&)>&, 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&) @ 0x0000000011841980 15. /build/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) @ 0x000000001621208e 16. /build/src/Storages/StorageReplicatedMergeTree.cpp:5228: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl[abi:se190107] const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000015f9a5fe 17. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000015ed8bfd 18. /build/src/Storages/StorageReplicatedMergeTree.cpp:2514: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x0000000015ec9aab 19. /build/src/Storages/StorageReplicatedMergeTree.cpp:2349: DB::StorageReplicatedMergeTree::executeLogEntry(DB::ReplicatedMergeTreeLogEntry&) @ 0x0000000015eba91b 20. /build/src/Storages/StorageReplicatedMergeTree.cpp:3876: bool std::__function::__policy_invoker&)>::__call_impl[abi:se190107])::$_1, bool (std::shared_ptr&)>>(std::__function::__policy_storage const*, std::shared_ptr&) @ 0x0000000015f9837e 21. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000165d6fc3 22. /build/src/Storages/StorageReplicatedMergeTree.cpp:3872: DB::StorageReplicatedMergeTree::processQueueEntry(std::shared_ptr) @ 0x0000000015efc18a 23. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001624c1b2 24. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000162f9c70 25. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x00000000162fa55a 26. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc6653 27. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000000fccc4c3 28. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc3d92 29. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fcca080 30. ? @ 0x00007fbc6213eac3 31. ? @ 0x00007fbc621d0850 (version 25.3.6.10636.altinitytest (altinity build)) 2025.07.28 11:53:41.539072 [ 4900 ] {} 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. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Access/AccessControl.cpp:646: DB::AccessControl::authenticate(DB::Credentials const&, Poco::Net::IPAddress const&, DB::ClientInfo const&) const @ 0x0000000013727552 4. /build/src/Interpreters/Session.cpp:371: DB::Session::authenticate(DB::Credentials const&, Poco::Net::SocketAddress const&, std::vector> const&) @ 0x0000000014a6dd4d 5. /build/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) @ 0x0000000016910eed 6. /build/src/Server/HTTPHandler.cpp:208: DB::HTTPHandler::authenticateUser(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&) @ 0x000000001686a6b6 7. /build/src/Server/HTTPHandler.cpp:224: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000001686aaa7 8. /build/src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x0000000016870807 9. /build/src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x0000000016907e99 10. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 11. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 12. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 13. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 14. ? @ 0x00007fbc6213eac3 15. ? @ 0x00007fbc621d0850 (version 25.3.6.10636.altinitytest (altinity build)) 2025.07.28 11:53:41.613511 [ 4900 ] {} 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. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Access/AccessControl.cpp:646: DB::AccessControl::authenticate(DB::Credentials const&, Poco::Net::IPAddress const&, DB::ClientInfo const&) const @ 0x0000000013727552 4. /build/src/Interpreters/Session.cpp:371: DB::Session::authenticate(DB::Credentials const&, Poco::Net::SocketAddress const&, std::vector> const&) @ 0x0000000014a6dd4d 5. /build/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) @ 0x0000000016910eed 6. /build/src/Server/HTTPHandler.cpp:208: DB::HTTPHandler::authenticateUser(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&) @ 0x000000001686a6b6 7. /build/src/Server/HTTPHandler.cpp:224: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000001686aaa7 8. /build/src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x0000000016870807 9. /build/src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x0000000016907e99 10. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 11. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 12. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 13. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 14. ? @ 0x00007fbc6213eac3 15. ? @ 0x00007fbc621d0850 (version 25.3.6.10636.altinitytest (altinity build)) 2025.07.28 11:53:41.754919 [ 3967 ] {} test_13.rmt2 (7f9b740d-015c-470e-8cc6-8ba33be0dc63): auto DB::StorageReplicatedMergeTree::processQueueEntry(ReplicatedMergeTreeQueue::SelectedEntryPtr)::(anonymous class)::operator()(LogEntryPtr &) const: Code: 86. DB::HTTPException: Received error from remote server http://146b4357c08d:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Ftest%2F01165%2Ftest_13%2Frmt%2Freplicas%2F1&part=20250728_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.6.10636.altinitytest (altinity build)) '. (RECEIVED_ERROR_FROM_REMOTE_IO_SERVER), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.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 const&, int&&, String const&, unsigned long&&, String const&) @ 0x000000000feda8d9 4. /build/src/IO/HTTPCommon.cpp:104: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x000000000feda6e2 5. /build/src/IO/HTTPCommon.cpp:93: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x000000000feda537 6. /build/src/IO/ReadWriteBufferFromHTTP.cpp:277: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x000000001184a4c4 7. /build/src/IO/ReadWriteBufferFromHTTP.cpp:285: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x000000001184a615 8. /build/src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x000000001184ae59 9. /build/src/IO/ReadWriteBufferFromHTTP.cpp:472: void std::__function::__policy_invoker::__call_impl[abi:se190107]>(std::__function::__policy_storage const*) @ 0x000000001184cedd 10. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001184858b 11. /build/src/IO/ReadWriteBufferFromHTTP.cpp:465: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x000000001184bf0b 12. /build/src/IO/ReadBuffer.h:60: DB::ReadBuffer::next() @ 0x000000000a148c7b 13. /build/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) @ 0x0000000011849fb2 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]>&)>&, 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&) @ 0x0000000011841980 15. /build/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) @ 0x000000001621208e 16. /build/src/Storages/StorageReplicatedMergeTree.cpp:5228: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl[abi:se190107] const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000015f9a5fe 17. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000015ed8bfd 18. /build/src/Storages/StorageReplicatedMergeTree.cpp:2514: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x0000000015ec9aab 19. /build/src/Storages/StorageReplicatedMergeTree.cpp:2349: DB::StorageReplicatedMergeTree::executeLogEntry(DB::ReplicatedMergeTreeLogEntry&) @ 0x0000000015eba91b 20. /build/src/Storages/StorageReplicatedMergeTree.cpp:3876: bool std::__function::__policy_invoker&)>::__call_impl[abi:se190107])::$_1, bool (std::shared_ptr&)>>(std::__function::__policy_storage const*, std::shared_ptr&) @ 0x0000000015f9837e 21. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000165d6fc3 22. /build/src/Storages/StorageReplicatedMergeTree.cpp:3872: DB::StorageReplicatedMergeTree::processQueueEntry(std::shared_ptr) @ 0x0000000015efc18a 23. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001624c1b2 24. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000162f9c70 25. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x00000000162fa55a 26. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc6653 27. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000000fccc4c3 28. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc3d92 29. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fcca080 30. ? @ 0x00007fbc6213eac3 31. ? @ 0x00007fbc621d0850 (version 25.3.6.10636.altinitytest (altinity build)) 2025.07.28 11:53:41.760677 [ 12807 ] {b3435dff-86f4-4375-80e6-3df51458a901} 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.6.10636.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.6.10636.altinitytest (altinity build)) (from [::1]:34600) (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. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.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 const&, int&&, String const&, unsigned long&&, String const&) @ 0x000000000feda8d9 4. /build/src/IO/HTTPCommon.cpp:104: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x000000000feda6e2 5. /build/src/IO/HTTPCommon.cpp:93: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x000000000feda537 6. /build/src/IO/ReadWriteBufferFromHTTP.cpp:277: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x000000001184a4c4 7. /build/src/IO/ReadWriteBufferFromHTTP.cpp:285: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x000000001184a615 8. /build/src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x000000001184ae59 9. /build/src/IO/ReadWriteBufferFromHTTP.cpp:472: void std::__function::__policy_invoker::__call_impl[abi:se190107]>(std::__function::__policy_storage const*) @ 0x000000001184cedd 10. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001184858b 11. /build/src/IO/ReadWriteBufferFromHTTP.cpp:465: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x000000001184bf0b 12. /build/src/IO/ReadBuffer.h:60: DB::ReadBuffer::next() @ 0x000000000a148c7b 13. /build/src/IO/ReadBuffer.h:96: DB::LineAsStringRowInputFormat::readRow(std::vector::mutable_ptr, std::allocator::mutable_ptr>>&, DB::RowReadExtension&) @ 0x0000000016ad8f2d 14. /build/src/Processors/Formats/IRowInputFormat.cpp:143: DB::IRowInputFormat::read() @ 0x0000000016a1fc72 15. /build/src/Processors/Formats/IInputFormat.cpp:19: DB::IInputFormat::generate() @ 0x00000000169c5536 16. /build/src/Processors/ISource.cpp:139: DB::ISource::tryGenerate() @ 0x00000000169a24fa 17. /build/src/Processors/ISource.cpp:108: DB::ISource::work() @ 0x00000000169a21e7 18. /build/src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x00000000169bd00f 19. /build/src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x00000000169b2105 20. /build/src/Processors/Executors/PipelineExecutor.cpp:170: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x00000000169b16a7 21. /build/src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x00000000169c081c 22. /build/src/Storages/StorageURL.cpp:467: DB::StorageURLSource::generate() @ 0x000000001601f496 23. /build/src/Processors/ISource.cpp:139: DB::ISource::tryGenerate() @ 0x00000000169a24fa 24. /build/src/Processors/ISource.cpp:108: DB::ISource::work() @ 0x00000000169a21e7 25. /build/src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x00000000169bd00f 26. /build/src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x00000000169b2105 27. /build/src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeSingleThread(unsigned long) @ 0x00000000169b23be 28. /build/src/Processors/Executors/PipelineExecutor.cpp:454: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x00000000169b0be7 29. /build/src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x00000000169b03f4 30. /build/src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:se190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169bfeab 31. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc3d92 2025.07.28 11:53:41.771792 [ 12807 ] {} 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.6.10636.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. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.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 const&, int&&, String const&, unsigned long&&, String const&) @ 0x000000000feda8d9 4. /build/src/IO/HTTPCommon.cpp:104: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x000000000feda6e2 5. /build/src/IO/HTTPCommon.cpp:93: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x000000000feda537 6. /build/src/IO/ReadWriteBufferFromHTTP.cpp:277: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x000000001184a4c4 7. /build/src/IO/ReadWriteBufferFromHTTP.cpp:285: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x000000001184a615 8. /build/src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x000000001184ae59 9. /build/src/IO/ReadWriteBufferFromHTTP.cpp:472: void std::__function::__policy_invoker::__call_impl[abi:se190107]>(std::__function::__policy_storage const*) @ 0x000000001184cedd 10. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001184858b 11. /build/src/IO/ReadWriteBufferFromHTTP.cpp:465: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x000000001184bf0b 12. /build/src/IO/ReadBuffer.h:60: DB::ReadBuffer::next() @ 0x000000000a148c7b 13. /build/src/IO/ReadBuffer.h:96: DB::LineAsStringRowInputFormat::readRow(std::vector::mutable_ptr, std::allocator::mutable_ptr>>&, DB::RowReadExtension&) @ 0x0000000016ad8f2d 14. /build/src/Processors/Formats/IRowInputFormat.cpp:143: DB::IRowInputFormat::read() @ 0x0000000016a1fc72 15. /build/src/Processors/Formats/IInputFormat.cpp:19: DB::IInputFormat::generate() @ 0x00000000169c5536 16. /build/src/Processors/ISource.cpp:139: DB::ISource::tryGenerate() @ 0x00000000169a24fa 17. /build/src/Processors/ISource.cpp:108: DB::ISource::work() @ 0x00000000169a21e7 18. /build/src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x00000000169bd00f 19. /build/src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x00000000169b2105 20. /build/src/Processors/Executors/PipelineExecutor.cpp:170: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x00000000169b16a7 21. /build/src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x00000000169c081c 22. /build/src/Storages/StorageURL.cpp:467: DB::StorageURLSource::generate() @ 0x000000001601f496 23. /build/src/Processors/ISource.cpp:139: DB::ISource::tryGenerate() @ 0x00000000169a24fa 24. /build/src/Processors/ISource.cpp:108: DB::ISource::work() @ 0x00000000169a21e7 25. /build/src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x00000000169bd00f 26. /build/src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x00000000169b2105 27. /build/src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeSingleThread(unsigned long) @ 0x00000000169b23be 28. /build/src/Processors/Executors/PipelineExecutor.cpp:454: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x00000000169b0be7 29. /build/src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x00000000169b03f4 30. /build/src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:se190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169bfeab 31. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc3d92 Job's origin stack trace: 0. /build/src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000000fc33b84 1. /build/src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000000fcc2ea7 2. /build/src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fcc535c 3. /build/src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000000fcc584d 4. /build/src/Common/ThreadPool.h:279: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x00000000169bf193 5. /build/src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x00000000169bf518 6. /build/src/Server/TCPHandler.cpp:1237: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x00000000168f1525 7. /build/src/Server/TCPHandler.cpp:678: DB::TCPHandler::runImpl() @ 0x00000000168e68e5 8. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 9. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 10. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 11. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 12. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 13. ? @ 0x00007fbc6213eac3 14. ? @ 0x00007fbc621d0850 2025.07.28 11:53:42.464424 [ 3972 ] {} test_13.rmt2 (7f9b740d-015c-470e-8cc6-8ba33be0dc63): auto DB::StorageReplicatedMergeTree::processQueueEntry(ReplicatedMergeTreeQueue::SelectedEntryPtr)::(anonymous class)::operator()(LogEntryPtr &) const: Code: 86. DB::HTTPException: Received error from remote server http://146b4357c08d:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Ftest%2F01165%2Ftest_13%2Frmt%2Freplicas%2F1&part=20250728_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.6.10636.altinitytest (altinity build)) '. (RECEIVED_ERROR_FROM_REMOTE_IO_SERVER), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.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 const&, int&&, String const&, unsigned long&&, String const&) @ 0x000000000feda8d9 4. /build/src/IO/HTTPCommon.cpp:104: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x000000000feda6e2 5. /build/src/IO/HTTPCommon.cpp:93: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x000000000feda537 6. /build/src/IO/ReadWriteBufferFromHTTP.cpp:277: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x000000001184a4c4 7. /build/src/IO/ReadWriteBufferFromHTTP.cpp:285: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x000000001184a615 8. /build/src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x000000001184ae59 9. /build/src/IO/ReadWriteBufferFromHTTP.cpp:472: void std::__function::__policy_invoker::__call_impl[abi:se190107]>(std::__function::__policy_storage const*) @ 0x000000001184cedd 10. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001184858b 11. /build/src/IO/ReadWriteBufferFromHTTP.cpp:465: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x000000001184bf0b 12. /build/src/IO/ReadBuffer.h:60: DB::ReadBuffer::next() @ 0x000000000a148c7b 13. /build/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) @ 0x0000000011849fb2 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]>&)>&, 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&) @ 0x0000000011841980 15. /build/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) @ 0x000000001621208e 16. /build/src/Storages/StorageReplicatedMergeTree.cpp:5228: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl[abi:se190107] const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000015f9a5fe 17. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000015ed8bfd 18. /build/src/Storages/StorageReplicatedMergeTree.cpp:2514: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x0000000015ec9aab 19. /build/src/Storages/StorageReplicatedMergeTree.cpp:2349: DB::StorageReplicatedMergeTree::executeLogEntry(DB::ReplicatedMergeTreeLogEntry&) @ 0x0000000015eba91b 20. /build/src/Storages/StorageReplicatedMergeTree.cpp:3876: bool std::__function::__policy_invoker&)>::__call_impl[abi:se190107])::$_1, bool (std::shared_ptr&)>>(std::__function::__policy_storage const*, std::shared_ptr&) @ 0x0000000015f9837e 21. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000165d6fc3 22. /build/src/Storages/StorageReplicatedMergeTree.cpp:3872: DB::StorageReplicatedMergeTree::processQueueEntry(std::shared_ptr) @ 0x0000000015efc18a 23. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001624c1b2 24. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000162f9c70 25. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x00000000162fa55a 26. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc6653 27. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000000fccc4c3 28. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc3d92 29. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fcca080 30. ? @ 0x00007fbc6213eac3 31. ? @ 0x00007fbc621d0850 (version 25.3.6.10636.altinitytest (altinity build)) 2025.07.28 11:53:43.223062 [ 5747 ] {f18b8dea-c89d-4cab-bf38-cffdb865003a} executeQuery: Code: 439. DB::Exception: Cannot schedule a task: failed to start the thread (threads=1, jobs=1). (CANNOT_SCHEDULE_TASK) (version 25.3.6.10636.altinitytest (altinity build)) (from [::1]:51152) (comment: 03312_line_numbers.sql) (query 6, line 14) (in query: SELECT 'Ok' FROM system.text_log WHERE event_date >= yesterday() AND message LIKE '%(query 2, line 8)%' AND message LIKE '%This is the second query%' LIMIT 1;), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000fccaeeb 4. /build/src/Common/ThreadPool.cpp:275: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000fccc813 5. /build/src/Common/ThreadPool.cpp:308: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fcc8286 6. /build/src/Common/ThreadPool.cpp:494: ThreadPoolImpl>::scheduleOrThrowOnError(std::function, Priority) @ 0x000000000fcc7a0e 7. /build/src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::spawnThreadsImpl() @ 0x00000000169b2c0c 8. /build/src/Processors/Executors/PipelineExecutor.cpp:394: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x00000000169b0ba7 9. /build/src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x00000000169b03f4 10. /build/src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:se190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169bfeab 11. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc3d92 12. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fcca080 13. ? @ 0x00007fbc6213eac3 14. ? @ 0x00007fbc621d0850 2025.07.28 11:53:43.282233 [ 5747 ] {} 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. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000fccaeeb 4. /build/src/Common/ThreadPool.cpp:275: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000fccc813 5. /build/src/Common/ThreadPool.cpp:308: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fcc8286 6. /build/src/Common/ThreadPool.cpp:494: ThreadPoolImpl>::scheduleOrThrowOnError(std::function, Priority) @ 0x000000000fcc7a0e 7. /build/src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::spawnThreadsImpl() @ 0x00000000169b2c0c 8. /build/src/Processors/Executors/PipelineExecutor.cpp:394: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x00000000169b0ba7 9. /build/src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x00000000169b03f4 10. /build/src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:se190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169bfeab 11. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc3d92 12. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fcca080 13. ? @ 0x00007fbc6213eac3 14. ? @ 0x00007fbc621d0850 Job's origin stack trace: 0. /build/src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000000fc33b84 1. /build/src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000000fcc2ea7 2. /build/src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fcc535c 3. /build/src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000000fcc584d 4. /build/src/Common/ThreadPool.h:279: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x00000000169bf193 5. /build/src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x00000000169bf518 6. /build/src/Server/TCPHandler.cpp:1237: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x00000000168f1525 7. /build/src/Server/TCPHandler.cpp:678: DB::TCPHandler::runImpl() @ 0x00000000168e68e5 8. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 9. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 10. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 11. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 12. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 13. ? @ 0x00007fbc6213eac3 14. ? @ 0x00007fbc621d0850 2025.07.28 11:53:43.282816 [ 3969 ] {} test_13.rmt2 (7f9b740d-015c-470e-8cc6-8ba33be0dc63): auto DB::StorageReplicatedMergeTree::processQueueEntry(ReplicatedMergeTreeQueue::SelectedEntryPtr)::(anonymous class)::operator()(LogEntryPtr &) const: Code: 86. DB::HTTPException: Received error from remote server http://146b4357c08d:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Ftest%2F01165%2Ftest_13%2Frmt%2Freplicas%2F1&part=20250728_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.6.10636.altinitytest (altinity build)) '. (RECEIVED_ERROR_FROM_REMOTE_IO_SERVER), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.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 const&, int&&, String const&, unsigned long&&, String const&) @ 0x000000000feda8d9 4. /build/src/IO/HTTPCommon.cpp:104: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x000000000feda6e2 5. /build/src/IO/HTTPCommon.cpp:93: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x000000000feda537 6. /build/src/IO/ReadWriteBufferFromHTTP.cpp:277: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x000000001184a4c4 7. /build/src/IO/ReadWriteBufferFromHTTP.cpp:285: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x000000001184a615 8. /build/src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x000000001184ae59 9. /build/src/IO/ReadWriteBufferFromHTTP.cpp:472: void std::__function::__policy_invoker::__call_impl[abi:se190107]>(std::__function::__policy_storage const*) @ 0x000000001184cedd 10. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001184858b 11. /build/src/IO/ReadWriteBufferFromHTTP.cpp:465: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x000000001184bf0b 12. /build/src/IO/ReadBuffer.h:60: DB::ReadBuffer::next() @ 0x000000000a148c7b 13. /build/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) @ 0x0000000011849fb2 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]>&)>&, 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&) @ 0x0000000011841980 15. /build/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) @ 0x000000001621208e 16. /build/src/Storages/StorageReplicatedMergeTree.cpp:5228: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl[abi:se190107] const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000015f9a5fe 17. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000015ed8bfd 18. /build/src/Storages/StorageReplicatedMergeTree.cpp:2514: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x0000000015ec9aab 19. /build/src/Storages/StorageReplicatedMergeTree.cpp:2349: DB::StorageReplicatedMergeTree::executeLogEntry(DB::ReplicatedMergeTreeLogEntry&) @ 0x0000000015eba91b 20. /build/src/Storages/StorageReplicatedMergeTree.cpp:3876: bool std::__function::__policy_invoker&)>::__call_impl[abi:se190107])::$_1, bool (std::shared_ptr&)>>(std::__function::__policy_storage const*, std::shared_ptr&) @ 0x0000000015f9837e 21. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000165d6fc3 22. /build/src/Storages/StorageReplicatedMergeTree.cpp:3872: DB::StorageReplicatedMergeTree::processQueueEntry(std::shared_ptr) @ 0x0000000015efc18a 23. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001624c1b2 24. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000162f9c70 25. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x00000000162fa55a 26. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc6653 27. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000000fccc4c3 28. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc3d92 29. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fcca080 30. ? @ 0x00007fbc6213eac3 31. ? @ 0x00007fbc621d0850 (version 25.3.6.10636.altinitytest (altinity build)) 2025.07.28 11:53:43.302495 [ 17287 ] {6a7ec91c-b65b-4ec9-9951-2698a4e55dc1} executeQuery: Code: 111. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(1_Bool :: 1, 'error_log'_String :: 2, _CAST(111_Int16, 'Int16'_String) :: 3) -> throwIf(1_Bool, 'error_log'_String, _CAST(111_Int16, 'Int16'_String)) UInt8 : 4'. (CANNOT_MANIPULATE_SIGSET) (version 25.3.6.10636.altinitytest (altinity build)) (from [::1]:45438) (comment: 03172_error_log_table_not_empty.sh) (query 1, line 2) (in query: SELECT throwIf(true, 'error_log', toInt16(111)) SETTINGS allow_custom_error_code_in_throwif=1;), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x000000000a06b56b 4. /build/src/Functions/throwIf.cpp:153: DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000e8193b5 5. /build/src/Functions/IFunctionAdaptors.cpp:10: DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000012d995fa 6. /build/src/Functions/IFunction.cpp:353: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d93b52 7. /build/src/Functions/IFunction.cpp:420: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d95059 8. /build/src/Functions/IFunction.cpp:498: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d95c72 9. /build/src/Interpreters/ExpressionActions.cpp:636: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x00000000145176f3 10. /build/src/Processors/Transforms/ExpressionTransform.cpp:25: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x0000000016c0b34c 11. /build/src/Processors/ISimpleTransform.h:33: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000011a9a453 12. /build/src/Processors/ISimpleTransform.cpp:89: DB::ISimpleTransform::work() @ 0x000000001699fca0 13. /build/src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x00000000169bd00f 14. /build/src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x00000000169b2105 15. /build/src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeSingleThread(unsigned long) @ 0x00000000169b23be 16. /build/src/Processors/Executors/PipelineExecutor.cpp:454: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x00000000169b0be7 17. /build/src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x00000000169b03f4 18. /build/src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:se190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169bfeab 19. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc3d92 20. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fcca080 21. ? @ 0x00007fbc6213eac3 22. ? @ 0x00007fbc621d0850 2025.07.28 11:53:43.326079 [ 17287 ] {} TCPHandler: Code: 111. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(1_Bool :: 1, 'error_log'_String :: 2, _CAST(111_Int16, 'Int16'_String) :: 3) -> throwIf(1_Bool, 'error_log'_String, _CAST(111_Int16, 'Int16'_String)) UInt8 : 4'. (CANNOT_MANIPULATE_SIGSET), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x000000000a06b56b 4. /build/src/Functions/throwIf.cpp:153: DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000e8193b5 5. /build/src/Functions/IFunctionAdaptors.cpp:10: DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000012d995fa 6. /build/src/Functions/IFunction.cpp:353: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d93b52 7. /build/src/Functions/IFunction.cpp:420: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d95059 8. /build/src/Functions/IFunction.cpp:498: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d95c72 9. /build/src/Interpreters/ExpressionActions.cpp:636: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x00000000145176f3 10. /build/src/Processors/Transforms/ExpressionTransform.cpp:25: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x0000000016c0b34c 11. /build/src/Processors/ISimpleTransform.h:33: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000011a9a453 12. /build/src/Processors/ISimpleTransform.cpp:89: DB::ISimpleTransform::work() @ 0x000000001699fca0 13. /build/src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x00000000169bd00f 14. /build/src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x00000000169b2105 15. /build/src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeSingleThread(unsigned long) @ 0x00000000169b23be 16. /build/src/Processors/Executors/PipelineExecutor.cpp:454: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x00000000169b0be7 17. /build/src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x00000000169b03f4 18. /build/src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:se190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169bfeab 19. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc3d92 20. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fcca080 21. ? @ 0x00007fbc6213eac3 22. ? @ 0x00007fbc621d0850 Job's origin stack trace: 0. /build/src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000000fc33b84 1. /build/src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000000fcc2ea7 2. /build/src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fcc535c 3. /build/src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000000fcc584d 4. /build/src/Common/ThreadPool.h:279: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x00000000169bf193 5. /build/src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x00000000169bf518 6. /build/src/Server/TCPHandler.cpp:1237: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x00000000168f1525 7. /build/src/Server/TCPHandler.cpp:678: DB::TCPHandler::runImpl() @ 0x00000000168e68e5 8. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 9. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 10. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 11. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 12. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 13. ? @ 0x00007fbc6213eac3 14. ? @ 0x00007fbc621d0850 2025.07.28 11:53:43.435165 [ 5879 ] {b1e4ec52-f588-4ee2-ba6e-bb8363a30857} executeQuery: Code: 42. DB::Exception: An incorrect number of arguments was specified for function 'makeDate32'. Expected 2 arguments, got 1 argument: In scope SELECT makeDate32(1980). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.6.10636.altinitytest (altinity build)) (from [::1]:40084) (comment: 02243_make_date32.sql) (query 71, line 80) (in query: select makeDate32(1980);), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&, String&&) @ 0x0000000012da6feb 4. /build/src/Functions/FunctionHelpers.cpp:184: DB::validateFunctionArguments(DB::IFunction const&, std::vector> const&, std::vector> const&, std::vector> const&) @ 0x0000000012da5831 5. /build/src/Functions/makeDate.cpp:99: DB::(anonymous namespace)::FunctionMakeDate::getReturnTypeImpl(std::vector> const&) const @ 0x000000000cf7c8cf 6. /build/src/Functions/IFunction.cpp:645: DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x0000000012d96b0c 7. /build/src/Functions/IFunction.cpp:577: DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x0000000012d9669c 8. /build/src/Functions/IFunction.cpp:606: DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x0000000012d96edc 9. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3544: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000014033cc9 10. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3838: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000014019a9e 11. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3980: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000014018e31 12. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:4304: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000014042fa7 13. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5605: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000014013749 14. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000140127f9 15. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000014011fce 16. /build/src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000001406ce8a 17. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000014973b42 18. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000001497268d 19. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000014974d24 20. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001492924b 21. /build/src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88641 22. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 23. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 24. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 25. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 26. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 27. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 28. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 29. ? @ 0x00007fbc6213eac3 30. ? @ 0x00007fbc621d0850 2025.07.28 11:53:43.446311 [ 5879 ] {} TCPHandler: Code: 42. DB::Exception: An incorrect number of arguments was specified for function 'makeDate32'. Expected 2 arguments, got 1 argument: In scope SELECT makeDate32(1980). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&, String&&) @ 0x0000000012da6feb 4. /build/src/Functions/FunctionHelpers.cpp:184: DB::validateFunctionArguments(DB::IFunction const&, std::vector> const&, std::vector> const&, std::vector> const&) @ 0x0000000012da5831 5. /build/src/Functions/makeDate.cpp:99: DB::(anonymous namespace)::FunctionMakeDate::getReturnTypeImpl(std::vector> const&) const @ 0x000000000cf7c8cf 6. /build/src/Functions/IFunction.cpp:645: DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x0000000012d96b0c 7. /build/src/Functions/IFunction.cpp:577: DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x0000000012d9669c 8. /build/src/Functions/IFunction.cpp:606: DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x0000000012d96edc 9. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3544: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000014033cc9 10. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3838: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000014019a9e 11. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3980: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000014018e31 12. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:4304: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000014042fa7 13. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5605: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000014013749 14. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000140127f9 15. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000014011fce 16. /build/src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000001406ce8a 17. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000014973b42 18. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000001497268d 19. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000014974d24 20. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001492924b 21. /build/src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88641 22. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 23. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 24. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 25. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 26. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 27. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 28. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 29. ? @ 0x00007fbc6213eac3 30. ? @ 0x00007fbc621d0850 2025.07.28 11:53:43.539650 [ 17287 ] {badee0e9-45da-4dd5-be9e-7a09281f95e0} executeQuery: Code: 222. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(1_Bool :: 1, 'error_log'_String :: 2, _CAST(222_Int16, 'Int16'_String) :: 3) -> throwIf(1_Bool, 'error_log'_String, _CAST(222_Int16, 'Int16'_String)) UInt8 : 4'. () (version 25.3.6.10636.altinitytest (altinity build)) (from [::1]:45438) (comment: 03172_error_log_table_not_empty.sh) (query 2, line 3) (in query: SELECT throwIf(true, 'error_log', toInt16(222)) SETTINGS allow_custom_error_code_in_throwif=1;), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x000000000a06b56b 4. /build/src/Functions/throwIf.cpp:153: DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000e8193b5 5. /build/src/Functions/IFunctionAdaptors.cpp:10: DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000012d995fa 6. /build/src/Functions/IFunction.cpp:353: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d93b52 7. /build/src/Functions/IFunction.cpp:420: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d95059 8. /build/src/Functions/IFunction.cpp:498: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d95c72 9. /build/src/Interpreters/ExpressionActions.cpp:636: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x00000000145176f3 10. /build/src/Processors/Transforms/ExpressionTransform.cpp:25: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x0000000016c0b34c 11. /build/src/Processors/ISimpleTransform.h:33: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000011a9a453 12. /build/src/Processors/ISimpleTransform.cpp:89: DB::ISimpleTransform::work() @ 0x000000001699fca0 13. /build/src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x00000000169bd00f 14. /build/src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x00000000169b2105 15. /build/src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeSingleThread(unsigned long) @ 0x00000000169b23be 16. /build/src/Processors/Executors/PipelineExecutor.cpp:454: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x00000000169b0be7 17. /build/src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x00000000169b03f4 18. /build/src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:se190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169bfeab 19. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc3d92 20. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fcca080 21. ? @ 0x00007fbc6213eac3 22. ? @ 0x00007fbc621d0850 2025.07.28 11:53:43.548368 [ 17287 ] {} TCPHandler: Code: 222. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(1_Bool :: 1, 'error_log'_String :: 2, _CAST(222_Int16, 'Int16'_String) :: 3) -> throwIf(1_Bool, 'error_log'_String, _CAST(222_Int16, 'Int16'_String)) UInt8 : 4'. (), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x000000000a06b56b 4. /build/src/Functions/throwIf.cpp:153: DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000e8193b5 5. /build/src/Functions/IFunctionAdaptors.cpp:10: DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000012d995fa 6. /build/src/Functions/IFunction.cpp:353: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d93b52 7. /build/src/Functions/IFunction.cpp:420: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d95059 8. /build/src/Functions/IFunction.cpp:498: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d95c72 9. /build/src/Interpreters/ExpressionActions.cpp:636: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x00000000145176f3 10. /build/src/Processors/Transforms/ExpressionTransform.cpp:25: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x0000000016c0b34c 11. /build/src/Processors/ISimpleTransform.h:33: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000011a9a453 12. /build/src/Processors/ISimpleTransform.cpp:89: DB::ISimpleTransform::work() @ 0x000000001699fca0 13. /build/src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x00000000169bd00f 14. /build/src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x00000000169b2105 15. /build/src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeSingleThread(unsigned long) @ 0x00000000169b23be 16. /build/src/Processors/Executors/PipelineExecutor.cpp:454: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x00000000169b0be7 17. /build/src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x00000000169b03f4 18. /build/src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:se190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169bfeab 19. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc3d92 20. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fcca080 21. ? @ 0x00007fbc6213eac3 22. ? @ 0x00007fbc621d0850 Job's origin stack trace: 0. /build/src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000000fc33b84 1. /build/src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000000fcc2ea7 2. /build/src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fcc535c 3. /build/src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000000fcc584d 4. /build/src/Common/ThreadPool.h:279: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x00000000169bf193 5. /build/src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x00000000169bf518 6. /build/src/Server/TCPHandler.cpp:1237: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x00000000168f1525 7. /build/src/Server/TCPHandler.cpp:678: DB::TCPHandler::runImpl() @ 0x00000000168e68e5 8. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 9. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 10. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 11. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 12. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 13. ? @ 0x00007fbc6213eac3 14. ? @ 0x00007fbc621d0850 2025.07.28 11:53:43.621918 [ 5879 ] {0b6e1ad7-6022-4ad0-9163-785ff665f704} executeQuery: Code: 42. DB::Exception: An incorrect number of arguments was specified for function 'makeDate32'. Expected 2 arguments, got 4 arguments: In scope SELECT makeDate32(1980, 1, 1, 1). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.6.10636.altinitytest (altinity build)) (from [::1]:40084) (comment: 02243_make_date32.sql) (query 72, line 81) (in query: select makeDate32(1980, 1, 1, 1);), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&, String&&) @ 0x0000000012da6feb 4. /build/src/Functions/FunctionHelpers.cpp:184: DB::validateFunctionArguments(DB::IFunction const&, std::vector> const&, std::vector> const&, std::vector> const&) @ 0x0000000012da5831 5. /build/src/Functions/makeDate.cpp:99: DB::(anonymous namespace)::FunctionMakeDate::getReturnTypeImpl(std::vector> const&) const @ 0x000000000cf7c8cf 6. /build/src/Functions/IFunction.cpp:645: DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x0000000012d96b0c 7. /build/src/Functions/IFunction.cpp:577: DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x0000000012d9669c 8. /build/src/Functions/IFunction.cpp:606: DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x0000000012d96edc 9. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3544: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000014033cc9 10. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3838: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000014019a9e 11. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3980: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000014018e31 12. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:4304: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000014042fa7 13. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5605: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000014013749 14. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000140127f9 15. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000014011fce 16. /build/src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000001406ce8a 17. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000014973b42 18. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000001497268d 19. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000014974d24 20. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001492924b 21. /build/src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88641 22. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 23. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 24. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 25. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 26. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 27. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 28. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 29. ? @ 0x00007fbc6213eac3 30. ? @ 0x00007fbc621d0850 2025.07.28 11:53:43.644215 [ 5879 ] {} TCPHandler: Code: 42. DB::Exception: An incorrect number of arguments was specified for function 'makeDate32'. Expected 2 arguments, got 4 arguments: In scope SELECT makeDate32(1980, 1, 1, 1). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&, String&&) @ 0x0000000012da6feb 4. /build/src/Functions/FunctionHelpers.cpp:184: DB::validateFunctionArguments(DB::IFunction const&, std::vector> const&, std::vector> const&, std::vector> const&) @ 0x0000000012da5831 5. /build/src/Functions/makeDate.cpp:99: DB::(anonymous namespace)::FunctionMakeDate::getReturnTypeImpl(std::vector> const&) const @ 0x000000000cf7c8cf 6. /build/src/Functions/IFunction.cpp:645: DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x0000000012d96b0c 7. /build/src/Functions/IFunction.cpp:577: DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x0000000012d9669c 8. /build/src/Functions/IFunction.cpp:606: DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x0000000012d96edc 9. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3544: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000014033cc9 10. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3838: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000014019a9e 11. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3980: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000014018e31 12. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:4304: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000014042fa7 13. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5605: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000014013749 14. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000140127f9 15. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000014011fce 16. /build/src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000001406ce8a 17. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000014973b42 18. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000001497268d 19. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000014974d24 20. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001492924b 21. /build/src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88641 22. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 23. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 24. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 25. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 26. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 27. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 28. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 29. ? @ 0x00007fbc6213eac3 30. ? @ 0x00007fbc621d0850 2025.07.28 11:53:43.734601 [ 17287 ] {dae39912-02e6-4795-a859-34b2111f4612} executeQuery: Code: 333. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(1_Bool :: 1, 'error_log'_String :: 2, _CAST(333_Int16, 'Int16'_String) :: 3) -> throwIf(1_Bool, 'error_log'_String, _CAST(333_Int16, 'Int16'_String)) UInt8 : 4'. () (version 25.3.6.10636.altinitytest (altinity build)) (from [::1]:45438) (comment: 03172_error_log_table_not_empty.sh) (query 3, line 4) (in query: SELECT throwIf(true, 'error_log', toInt16(333)) SETTINGS allow_custom_error_code_in_throwif=1;), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x000000000a06b56b 4. /build/src/Functions/throwIf.cpp:153: DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000e8193b5 5. /build/src/Functions/IFunctionAdaptors.cpp:10: DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000012d995fa 6. /build/src/Functions/IFunction.cpp:353: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d93b52 7. /build/src/Functions/IFunction.cpp:420: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d95059 8. /build/src/Functions/IFunction.cpp:498: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d95c72 9. /build/src/Interpreters/ExpressionActions.cpp:636: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x00000000145176f3 10. /build/src/Processors/Transforms/ExpressionTransform.cpp:25: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x0000000016c0b34c 11. /build/src/Processors/ISimpleTransform.h:33: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000011a9a453 12. /build/src/Processors/ISimpleTransform.cpp:89: DB::ISimpleTransform::work() @ 0x000000001699fca0 13. /build/src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x00000000169bd00f 14. /build/src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x00000000169b2105 15. /build/src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeSingleThread(unsigned long) @ 0x00000000169b23be 16. /build/src/Processors/Executors/PipelineExecutor.cpp:454: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x00000000169b0be7 17. /build/src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x00000000169b03f4 18. /build/src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:se190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169bfeab 19. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc3d92 20. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fcca080 21. ? @ 0x00007fbc6213eac3 22. ? @ 0x00007fbc621d0850 2025.07.28 11:53:43.754300 [ 17287 ] {} TCPHandler: Code: 333. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(1_Bool :: 1, 'error_log'_String :: 2, _CAST(333_Int16, 'Int16'_String) :: 3) -> throwIf(1_Bool, 'error_log'_String, _CAST(333_Int16, 'Int16'_String)) UInt8 : 4'. (), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x000000000a06b56b 4. /build/src/Functions/throwIf.cpp:153: DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000e8193b5 5. /build/src/Functions/IFunctionAdaptors.cpp:10: DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000012d995fa 6. /build/src/Functions/IFunction.cpp:353: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d93b52 7. /build/src/Functions/IFunction.cpp:420: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d95059 8. /build/src/Functions/IFunction.cpp:498: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d95c72 9. /build/src/Interpreters/ExpressionActions.cpp:636: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x00000000145176f3 10. /build/src/Processors/Transforms/ExpressionTransform.cpp:25: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x0000000016c0b34c 11. /build/src/Processors/ISimpleTransform.h:33: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000011a9a453 12. /build/src/Processors/ISimpleTransform.cpp:89: DB::ISimpleTransform::work() @ 0x000000001699fca0 13. /build/src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x00000000169bd00f 14. /build/src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x00000000169b2105 15. /build/src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeSingleThread(unsigned long) @ 0x00000000169b23be 16. /build/src/Processors/Executors/PipelineExecutor.cpp:454: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x00000000169b0be7 17. /build/src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x00000000169b03f4 18. /build/src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:se190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169bfeab 19. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc3d92 20. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fcca080 21. ? @ 0x00007fbc6213eac3 22. ? @ 0x00007fbc621d0850 Job's origin stack trace: 0. /build/src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000000fc33b84 1. /build/src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000000fcc2ea7 2. /build/src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fcc535c 3. /build/src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000000fcc584d 4. /build/src/Common/ThreadPool.h:279: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x00000000169bf193 5. /build/src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x00000000169bf518 6. /build/src/Server/TCPHandler.cpp:1237: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x00000000168f1525 7. /build/src/Server/TCPHandler.cpp:678: DB::TCPHandler::runImpl() @ 0x00000000168e68e5 8. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 9. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 10. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 11. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 12. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 13. ? @ 0x00007fbc6213eac3 14. ? @ 0x00007fbc621d0850 2025.07.28 11:53:44.088118 [ 17251 ] {6c930e66-1444-4d5c-9175-82cce10c0a7d} executeQuery: Code: 16. DB::Exception: No such column arr in table test_ixw674u7.t_rename_alter (0f1b84ac-c444-44d8-9e20-952b7b41ef44). (NO_SUCH_COLUMN_IN_TABLE) (version 25.3.6.10636.altinitytest (altinity build)) (from [::1]:45650) (comment: 03352_concurrent_rename_alter.sh) (query 1, line 1) (in query: INSERT INTO t_rename_alter (id, dt, arr) SELECT 1, now(), [(now(), 1, 'a', 'b')]), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x000000000a6a1e2b 4. /build/src/Interpreters/InterpreterInsertQuery.cpp:258: DB::InterpreterInsertQuery::getSampleBlockImpl(std::vector> const&, std::shared_ptr const&, std::shared_ptr const&, bool, bool) @ 0x000000001492cf06 5. /build/src/Interpreters/InterpreterInsertQuery.cpp:200: DB::InterpreterInsertQuery::getSampleBlock(DB::ASTInsertQuery const&, std::shared_ptr const&, std::shared_ptr const&, std::shared_ptr, bool, bool) @ 0x000000001492c400 6. /build/src/Interpreters/InterpreterInsertQuery.cpp:838: DB::InterpreterInsertQuery::execute() @ 0x0000000014933ae7 7. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88dc9 8. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 9. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 10. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 11. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 12. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 13. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 14. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 15. ? @ 0x00007fbc6213eac3 16. ? @ 0x00007fbc621d0850 2025.07.28 11:53:44.097229 [ 17251 ] {} TCPHandler: Code: 16. DB::Exception: No such column arr in table test_ixw674u7.t_rename_alter (0f1b84ac-c444-44d8-9e20-952b7b41ef44). (NO_SUCH_COLUMN_IN_TABLE), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x000000000a6a1e2b 4. /build/src/Interpreters/InterpreterInsertQuery.cpp:258: DB::InterpreterInsertQuery::getSampleBlockImpl(std::vector> const&, std::shared_ptr const&, std::shared_ptr const&, bool, bool) @ 0x000000001492cf06 5. /build/src/Interpreters/InterpreterInsertQuery.cpp:200: DB::InterpreterInsertQuery::getSampleBlock(DB::ASTInsertQuery const&, std::shared_ptr const&, std::shared_ptr const&, std::shared_ptr, bool, bool) @ 0x000000001492c400 6. /build/src/Interpreters/InterpreterInsertQuery.cpp:838: DB::InterpreterInsertQuery::execute() @ 0x0000000014933ae7 7. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88dc9 8. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 9. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 10. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 11. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 12. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 13. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 14. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 15. ? @ 0x00007fbc6213eac3 16. ? @ 0x00007fbc621d0850 2025.07.28 11:53:44.227355 [ 5327 ] {1e7db3f8-4522-4912-9820-a57c731852fc} executeQuery: Code: 16. DB::Exception: No such column arr in table test_ixw674u7.t_rename_alter (0f1b84ac-c444-44d8-9e20-952b7b41ef44). (NO_SUCH_COLUMN_IN_TABLE) (version 25.3.6.10636.altinitytest (altinity build)) (from [::1]:45684) (comment: 03352_concurrent_rename_alter.sh) (query 1, line 1) (in query: INSERT INTO t_rename_alter (id, dt, arr) SELECT 1, now(), [(now(), 1, 'a', 'b')]), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x000000000a6a1e2b 4. /build/src/Interpreters/InterpreterInsertQuery.cpp:258: DB::InterpreterInsertQuery::getSampleBlockImpl(std::vector> const&, std::shared_ptr const&, std::shared_ptr const&, bool, bool) @ 0x000000001492cf06 5. /build/src/Interpreters/InterpreterInsertQuery.cpp:200: DB::InterpreterInsertQuery::getSampleBlock(DB::ASTInsertQuery const&, std::shared_ptr const&, std::shared_ptr const&, std::shared_ptr, bool, bool) @ 0x000000001492c400 6. /build/src/Interpreters/InterpreterInsertQuery.cpp:838: DB::InterpreterInsertQuery::execute() @ 0x0000000014933ae7 7. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88dc9 8. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 9. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 10. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 11. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 12. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 13. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 14. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 15. ? @ 0x00007fbc6213eac3 16. ? @ 0x00007fbc621d0850 2025.07.28 11:53:44.232315 [ 5327 ] {} TCPHandler: Code: 16. DB::Exception: No such column arr in table test_ixw674u7.t_rename_alter (0f1b84ac-c444-44d8-9e20-952b7b41ef44). (NO_SUCH_COLUMN_IN_TABLE), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x000000000a6a1e2b 4. /build/src/Interpreters/InterpreterInsertQuery.cpp:258: DB::InterpreterInsertQuery::getSampleBlockImpl(std::vector> const&, std::shared_ptr const&, std::shared_ptr const&, bool, bool) @ 0x000000001492cf06 5. /build/src/Interpreters/InterpreterInsertQuery.cpp:200: DB::InterpreterInsertQuery::getSampleBlock(DB::ASTInsertQuery const&, std::shared_ptr const&, std::shared_ptr const&, std::shared_ptr, bool, bool) @ 0x000000001492c400 6. /build/src/Interpreters/InterpreterInsertQuery.cpp:838: DB::InterpreterInsertQuery::execute() @ 0x0000000014933ae7 7. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88dc9 8. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 9. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 10. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 11. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 12. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 13. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 14. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 15. ? @ 0x00007fbc6213eac3 16. ? @ 0x00007fbc621d0850 2025.07.28 11:53:44.257345 [ 3969 ] {} test_13.rmt2 (7f9b740d-015c-470e-8cc6-8ba33be0dc63): auto DB::StorageReplicatedMergeTree::processQueueEntry(ReplicatedMergeTreeQueue::SelectedEntryPtr)::(anonymous class)::operator()(LogEntryPtr &) const: Code: 86. DB::HTTPException: Received error from remote server http://146b4357c08d:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Ftest%2F01165%2Ftest_13%2Frmt%2Freplicas%2F1&part=20250728_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.6.10636.altinitytest (altinity build)) '. (RECEIVED_ERROR_FROM_REMOTE_IO_SERVER), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.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 const&, int&&, String const&, unsigned long&&, String const&) @ 0x000000000feda8d9 4. /build/src/IO/HTTPCommon.cpp:104: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x000000000feda6e2 5. /build/src/IO/HTTPCommon.cpp:93: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x000000000feda537 6. /build/src/IO/ReadWriteBufferFromHTTP.cpp:277: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x000000001184a4c4 7. /build/src/IO/ReadWriteBufferFromHTTP.cpp:285: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x000000001184a615 8. /build/src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x000000001184ae59 9. /build/src/IO/ReadWriteBufferFromHTTP.cpp:472: void std::__function::__policy_invoker::__call_impl[abi:se190107]>(std::__function::__policy_storage const*) @ 0x000000001184cedd 10. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001184858b 11. /build/src/IO/ReadWriteBufferFromHTTP.cpp:465: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x000000001184bf0b 12. /build/src/IO/ReadBuffer.h:60: DB::ReadBuffer::next() @ 0x000000000a148c7b 13. /build/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) @ 0x0000000011849fb2 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]>&)>&, 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&) @ 0x0000000011841980 15. /build/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) @ 0x000000001621208e 16. /build/src/Storages/StorageReplicatedMergeTree.cpp:5228: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl[abi:se190107] const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000015f9a5fe 17. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000015ed8bfd 18. /build/src/Storages/StorageReplicatedMergeTree.cpp:2514: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x0000000015ec9aab 19. /build/src/Storages/StorageReplicatedMergeTree.cpp:2349: DB::StorageReplicatedMergeTree::executeLogEntry(DB::ReplicatedMergeTreeLogEntry&) @ 0x0000000015eba91b 20. /build/src/Storages/StorageReplicatedMergeTree.cpp:3876: bool std::__function::__policy_invoker&)>::__call_impl[abi:se190107])::$_1, bool (std::shared_ptr&)>>(std::__function::__policy_storage const*, std::shared_ptr&) @ 0x0000000015f9837e 21. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000165d6fc3 22. /build/src/Storages/StorageReplicatedMergeTree.cpp:3872: DB::StorageReplicatedMergeTree::processQueueEntry(std::shared_ptr) @ 0x0000000015efc18a 23. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001624c1b2 24. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000162f9c70 25. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x00000000162fa55a 26. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc6653 27. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000000fccc4c3 28. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc3d92 29. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fcca080 30. ? @ 0x00007fbc6213eac3 31. ? @ 0x00007fbc621d0850 (version 25.3.6.10636.altinitytest (altinity build)) 2025.07.28 11:53:44.269898 [ 17208 ] {08c29929-a397-472d-ad79-754acd94e909} executeQuery: Code: 16. DB::Exception: No such column arr in table test_ixw674u7.t_rename_alter (0f1b84ac-c444-44d8-9e20-952b7b41ef44). (NO_SUCH_COLUMN_IN_TABLE) (version 25.3.6.10636.altinitytest (altinity build)) (from [::1]:45730) (comment: 03352_concurrent_rename_alter.sh) (query 1, line 1) (in query: INSERT INTO t_rename_alter (id, dt, arr) SELECT 1, now(), [(now(), 1, 'a', 'b')]), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x000000000a6a1e2b 4. /build/src/Interpreters/InterpreterInsertQuery.cpp:258: DB::InterpreterInsertQuery::getSampleBlockImpl(std::vector> const&, std::shared_ptr const&, std::shared_ptr const&, bool, bool) @ 0x000000001492cf06 5. /build/src/Interpreters/InterpreterInsertQuery.cpp:200: DB::InterpreterInsertQuery::getSampleBlock(DB::ASTInsertQuery const&, std::shared_ptr const&, std::shared_ptr const&, std::shared_ptr, bool, bool) @ 0x000000001492c400 6. /build/src/Interpreters/InterpreterInsertQuery.cpp:838: DB::InterpreterInsertQuery::execute() @ 0x0000000014933ae7 7. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88dc9 8. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 9. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 10. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 11. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 12. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 13. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 14. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 15. ? @ 0x00007fbc6213eac3 16. ? @ 0x00007fbc621d0850 2025.07.28 11:53:44.294858 [ 17208 ] {} TCPHandler: Code: 16. DB::Exception: No such column arr in table test_ixw674u7.t_rename_alter (0f1b84ac-c444-44d8-9e20-952b7b41ef44). (NO_SUCH_COLUMN_IN_TABLE), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x000000000a6a1e2b 4. /build/src/Interpreters/InterpreterInsertQuery.cpp:258: DB::InterpreterInsertQuery::getSampleBlockImpl(std::vector> const&, std::shared_ptr const&, std::shared_ptr const&, bool, bool) @ 0x000000001492cf06 5. /build/src/Interpreters/InterpreterInsertQuery.cpp:200: DB::InterpreterInsertQuery::getSampleBlock(DB::ASTInsertQuery const&, std::shared_ptr const&, std::shared_ptr const&, std::shared_ptr, bool, bool) @ 0x000000001492c400 6. /build/src/Interpreters/InterpreterInsertQuery.cpp:838: DB::InterpreterInsertQuery::execute() @ 0x0000000014933ae7 7. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88dc9 8. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 9. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 10. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 11. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 12. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 13. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 14. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 15. ? @ 0x00007fbc6213eac3 16. ? @ 0x00007fbc621d0850 2025.07.28 11:53:44.303614 [ 17203 ] {f8c6a41b-658c-40a4-aa46-339ed9ee0d3f} executeQuery: Code: 16. DB::Exception: No such column arr in table test_ixw674u7.t_rename_alter (0f1b84ac-c444-44d8-9e20-952b7b41ef44). (NO_SUCH_COLUMN_IN_TABLE) (version 25.3.6.10636.altinitytest (altinity build)) (from [::1]:45732) (comment: 03352_concurrent_rename_alter.sh) (query 1, line 1) (in query: INSERT INTO t_rename_alter (id, dt, arr) SELECT 1, now(), [(now(), 1, 'a', 'b')]), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x000000000a6a1e2b 4. /build/src/Interpreters/InterpreterInsertQuery.cpp:258: DB::InterpreterInsertQuery::getSampleBlockImpl(std::vector> const&, std::shared_ptr const&, std::shared_ptr const&, bool, bool) @ 0x000000001492cf06 5. /build/src/Interpreters/InterpreterInsertQuery.cpp:200: DB::InterpreterInsertQuery::getSampleBlock(DB::ASTInsertQuery const&, std::shared_ptr const&, std::shared_ptr const&, std::shared_ptr, bool, bool) @ 0x000000001492c400 6. /build/src/Interpreters/InterpreterInsertQuery.cpp:838: DB::InterpreterInsertQuery::execute() @ 0x0000000014933ae7 7. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88dc9 8. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 9. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 10. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 11. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 12. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 13. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 14. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 15. ? @ 0x00007fbc6213eac3 16. ? @ 0x00007fbc621d0850 2025.07.28 11:53:44.309115 [ 17203 ] {} TCPHandler: Code: 16. DB::Exception: No such column arr in table test_ixw674u7.t_rename_alter (0f1b84ac-c444-44d8-9e20-952b7b41ef44). (NO_SUCH_COLUMN_IN_TABLE), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x000000000a6a1e2b 4. /build/src/Interpreters/InterpreterInsertQuery.cpp:258: DB::InterpreterInsertQuery::getSampleBlockImpl(std::vector> const&, std::shared_ptr const&, std::shared_ptr const&, bool, bool) @ 0x000000001492cf06 5. /build/src/Interpreters/InterpreterInsertQuery.cpp:200: DB::InterpreterInsertQuery::getSampleBlock(DB::ASTInsertQuery const&, std::shared_ptr const&, std::shared_ptr const&, std::shared_ptr, bool, bool) @ 0x000000001492c400 6. /build/src/Interpreters/InterpreterInsertQuery.cpp:838: DB::InterpreterInsertQuery::execute() @ 0x0000000014933ae7 7. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88dc9 8. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 9. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 10. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 11. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 12. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 13. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 14. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 15. ? @ 0x00007fbc6213eac3 16. ? @ 0x00007fbc621d0850 2025.07.28 11:53:44.363782 [ 17611 ] {29510b1f-83f9-4384-a135-f71ee118558e} executeQuery: Code: 16. DB::Exception: No such column arr in table test_ixw674u7.t_rename_alter (0f1b84ac-c444-44d8-9e20-952b7b41ef44). (NO_SUCH_COLUMN_IN_TABLE) (version 25.3.6.10636.altinitytest (altinity build)) (from [::1]:45750) (comment: 03352_concurrent_rename_alter.sh) (query 1, line 1) (in query: INSERT INTO t_rename_alter (id, dt, arr) SELECT 1, now(), [(now(), 1, 'a', 'b')]), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x000000000a6a1e2b 4. /build/src/Interpreters/InterpreterInsertQuery.cpp:258: DB::InterpreterInsertQuery::getSampleBlockImpl(std::vector> const&, std::shared_ptr const&, std::shared_ptr const&, bool, bool) @ 0x000000001492cf06 5. /build/src/Interpreters/InterpreterInsertQuery.cpp:200: DB::InterpreterInsertQuery::getSampleBlock(DB::ASTInsertQuery const&, std::shared_ptr const&, std::shared_ptr const&, std::shared_ptr, bool, bool) @ 0x000000001492c400 6. /build/src/Interpreters/InterpreterInsertQuery.cpp:838: DB::InterpreterInsertQuery::execute() @ 0x0000000014933ae7 7. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88dc9 8. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 9. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 10. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 11. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 12. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 13. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 14. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 15. ? @ 0x00007fbc6213eac3 16. ? @ 0x00007fbc621d0850 2025.07.28 11:53:44.372135 [ 17611 ] {} TCPHandler: Code: 16. DB::Exception: No such column arr in table test_ixw674u7.t_rename_alter (0f1b84ac-c444-44d8-9e20-952b7b41ef44). (NO_SUCH_COLUMN_IN_TABLE), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x000000000a6a1e2b 4. /build/src/Interpreters/InterpreterInsertQuery.cpp:258: DB::InterpreterInsertQuery::getSampleBlockImpl(std::vector> const&, std::shared_ptr const&, std::shared_ptr const&, bool, bool) @ 0x000000001492cf06 5. /build/src/Interpreters/InterpreterInsertQuery.cpp:200: DB::InterpreterInsertQuery::getSampleBlock(DB::ASTInsertQuery const&, std::shared_ptr const&, std::shared_ptr const&, std::shared_ptr, bool, bool) @ 0x000000001492c400 6. /build/src/Interpreters/InterpreterInsertQuery.cpp:838: DB::InterpreterInsertQuery::execute() @ 0x0000000014933ae7 7. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88dc9 8. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 9. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 10. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 11. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 12. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 13. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 14. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 15. ? @ 0x00007fbc6213eac3 16. ? @ 0x00007fbc621d0850 2025.07.28 11:53:44.412867 [ 5327 ] {fba35149-0a58-4126-b4e7-1de198ed4b32} executeQuery: Code: 16. DB::Exception: No such column arr in table test_ixw674u7.t_rename_alter (0f1b84ac-c444-44d8-9e20-952b7b41ef44). (NO_SUCH_COLUMN_IN_TABLE) (version 25.3.6.10636.altinitytest (altinity build)) (from [::1]:45786) (comment: 03352_concurrent_rename_alter.sh) (query 1, line 1) (in query: INSERT INTO t_rename_alter (id, dt, arr) SELECT 1, now(), [(now(), 1, 'a', 'b')]), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x000000000a6a1e2b 4. /build/src/Interpreters/InterpreterInsertQuery.cpp:258: DB::InterpreterInsertQuery::getSampleBlockImpl(std::vector> const&, std::shared_ptr const&, std::shared_ptr const&, bool, bool) @ 0x000000001492cf06 5. /build/src/Interpreters/InterpreterInsertQuery.cpp:200: DB::InterpreterInsertQuery::getSampleBlock(DB::ASTInsertQuery const&, std::shared_ptr const&, std::shared_ptr const&, std::shared_ptr, bool, bool) @ 0x000000001492c400 6. /build/src/Interpreters/InterpreterInsertQuery.cpp:838: DB::InterpreterInsertQuery::execute() @ 0x0000000014933ae7 7. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88dc9 8. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 9. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 10. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 11. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 12. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 13. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 14. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 15. ? @ 0x00007fbc6213eac3 16. ? @ 0x00007fbc621d0850 2025.07.28 11:53:44.421857 [ 5327 ] {} TCPHandler: Code: 16. DB::Exception: No such column arr in table test_ixw674u7.t_rename_alter (0f1b84ac-c444-44d8-9e20-952b7b41ef44). (NO_SUCH_COLUMN_IN_TABLE), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x000000000a6a1e2b 4. /build/src/Interpreters/InterpreterInsertQuery.cpp:258: DB::InterpreterInsertQuery::getSampleBlockImpl(std::vector> const&, std::shared_ptr const&, std::shared_ptr const&, bool, bool) @ 0x000000001492cf06 5. /build/src/Interpreters/InterpreterInsertQuery.cpp:200: DB::InterpreterInsertQuery::getSampleBlock(DB::ASTInsertQuery const&, std::shared_ptr const&, std::shared_ptr const&, std::shared_ptr, bool, bool) @ 0x000000001492c400 6. /build/src/Interpreters/InterpreterInsertQuery.cpp:838: DB::InterpreterInsertQuery::execute() @ 0x0000000014933ae7 7. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88dc9 8. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 9. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 10. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 11. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 12. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 13. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 14. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 15. ? @ 0x00007fbc6213eac3 16. ? @ 0x00007fbc621d0850 2025.07.28 11:53:44.564010 [ 11826 ] {13782145-e8a6-4355-b219-6d495d459c64} executeQuery: Code: 62. DB::Exception: Cannot TRUNCATE dictionary. (SYNTAX_ERROR) (version 25.3.6.10636.altinitytest (altinity build)) (from [::1]:45624) (comment: 01225_drop_dictionary_as_table.sql) (query 4, line 14) (in query: DROP TABLE dict;), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000000a074fcb 4. /build/src/Interpreters/InterpreterDropQuery.cpp:266: DB::InterpreterDropQuery::executeToTableImpl(std::shared_ptr const&, DB::ASTDropQuery&, std::shared_ptr&, StrongTypedef, DB::UUIDTag>&) @ 0x0000000014915b7b 5. /build/src/Interpreters/InterpreterDropQuery.cpp:118: DB::InterpreterDropQuery::executeToTable(DB::ASTDropQuery&) @ 0x00000000149137b4 6. /build/src/Interpreters/InterpreterDropQuery.cpp:91: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000014912f07 7. /build/src/Interpreters/InterpreterDropQuery.cpp:72: DB::InterpreterDropQuery::execute() @ 0x0000000014912b65 8. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88dc9 9. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 10. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 11. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 12. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 13. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 14. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 15. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 16. ? @ 0x00007fbc6213eac3 17. ? @ 0x00007fbc621d0850 2025.07.28 11:53:44.586397 [ 11826 ] {} TCPHandler: Code: 62. DB::Exception: Cannot TRUNCATE dictionary. (SYNTAX_ERROR), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000000a074fcb 4. /build/src/Interpreters/InterpreterDropQuery.cpp:266: DB::InterpreterDropQuery::executeToTableImpl(std::shared_ptr const&, DB::ASTDropQuery&, std::shared_ptr&, StrongTypedef, DB::UUIDTag>&) @ 0x0000000014915b7b 5. /build/src/Interpreters/InterpreterDropQuery.cpp:118: DB::InterpreterDropQuery::executeToTable(DB::ASTDropQuery&) @ 0x00000000149137b4 6. /build/src/Interpreters/InterpreterDropQuery.cpp:91: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000014912f07 7. /build/src/Interpreters/InterpreterDropQuery.cpp:72: DB::InterpreterDropQuery::execute() @ 0x0000000014912b65 8. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88dc9 9. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 10. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 11. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 12. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 13. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 14. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 15. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 16. ? @ 0x00007fbc6213eac3 17. ? @ 0x00007fbc621d0850 2025.07.28 11:53:44.605820 [ 17611 ] {366488c5-0872-4747-a533-49cdbd4588d6} executeQuery: Code: 16. DB::Exception: No such column arr in table test_ixw674u7.t_rename_alter (0f1b84ac-c444-44d8-9e20-952b7b41ef44). (NO_SUCH_COLUMN_IN_TABLE) (version 25.3.6.10636.altinitytest (altinity build)) (from [::1]:45842) (comment: 03352_concurrent_rename_alter.sh) (query 1, line 1) (in query: INSERT INTO t_rename_alter (id, dt, arr) SELECT 1, now(), [(now(), 1, 'a', 'b')]), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x000000000a6a1e2b 4. /build/src/Interpreters/InterpreterInsertQuery.cpp:258: DB::InterpreterInsertQuery::getSampleBlockImpl(std::vector> const&, std::shared_ptr const&, std::shared_ptr const&, bool, bool) @ 0x000000001492cf06 5. /build/src/Interpreters/InterpreterInsertQuery.cpp:200: DB::InterpreterInsertQuery::getSampleBlock(DB::ASTInsertQuery const&, std::shared_ptr const&, std::shared_ptr const&, std::shared_ptr, bool, bool) @ 0x000000001492c400 6. /build/src/Interpreters/InterpreterInsertQuery.cpp:838: DB::InterpreterInsertQuery::execute() @ 0x0000000014933ae7 7. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88dc9 8. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 9. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 10. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 11. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 12. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 13. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 14. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 15. ? @ 0x00007fbc6213eac3 16. ? @ 0x00007fbc621d0850 2025.07.28 11:53:44.616143 [ 17611 ] {} TCPHandler: Code: 16. DB::Exception: No such column arr in table test_ixw674u7.t_rename_alter (0f1b84ac-c444-44d8-9e20-952b7b41ef44). (NO_SUCH_COLUMN_IN_TABLE), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x000000000a6a1e2b 4. /build/src/Interpreters/InterpreterInsertQuery.cpp:258: DB::InterpreterInsertQuery::getSampleBlockImpl(std::vector> const&, std::shared_ptr const&, std::shared_ptr const&, bool, bool) @ 0x000000001492cf06 5. /build/src/Interpreters/InterpreterInsertQuery.cpp:200: DB::InterpreterInsertQuery::getSampleBlock(DB::ASTInsertQuery const&, std::shared_ptr const&, std::shared_ptr const&, std::shared_ptr, bool, bool) @ 0x000000001492c400 6. /build/src/Interpreters/InterpreterInsertQuery.cpp:838: DB::InterpreterInsertQuery::execute() @ 0x0000000014933ae7 7. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88dc9 8. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 9. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 10. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 11. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 12. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 13. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 14. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 15. ? @ 0x00007fbc6213eac3 16. ? @ 0x00007fbc621d0850 2025.07.28 11:53:44.629423 [ 5327 ] {21290bb8-d969-4662-8f6e-fe4c09ce2bf5} executeQuery: Code: 16. DB::Exception: No such column arr in table test_ixw674u7.t_rename_alter (0f1b84ac-c444-44d8-9e20-952b7b41ef44). (NO_SUCH_COLUMN_IN_TABLE) (version 25.3.6.10636.altinitytest (altinity build)) (from [::1]:45854) (comment: 03352_concurrent_rename_alter.sh) (query 1, line 1) (in query: INSERT INTO t_rename_alter (id, dt, arr) SELECT 1, now(), [(now(), 1, 'a', 'b')]), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x000000000a6a1e2b 4. /build/src/Interpreters/InterpreterInsertQuery.cpp:258: DB::InterpreterInsertQuery::getSampleBlockImpl(std::vector> const&, std::shared_ptr const&, std::shared_ptr const&, bool, bool) @ 0x000000001492cf06 5. /build/src/Interpreters/InterpreterInsertQuery.cpp:200: DB::InterpreterInsertQuery::getSampleBlock(DB::ASTInsertQuery const&, std::shared_ptr const&, std::shared_ptr const&, std::shared_ptr, bool, bool) @ 0x000000001492c400 6. /build/src/Interpreters/InterpreterInsertQuery.cpp:838: DB::InterpreterInsertQuery::execute() @ 0x0000000014933ae7 7. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88dc9 8. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 9. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 10. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 11. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 12. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 13. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 14. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 15. ? @ 0x00007fbc6213eac3 16. ? @ 0x00007fbc621d0850 2025.07.28 11:53:44.638930 [ 5327 ] {} TCPHandler: Code: 16. DB::Exception: No such column arr in table test_ixw674u7.t_rename_alter (0f1b84ac-c444-44d8-9e20-952b7b41ef44). (NO_SUCH_COLUMN_IN_TABLE), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x000000000a6a1e2b 4. /build/src/Interpreters/InterpreterInsertQuery.cpp:258: DB::InterpreterInsertQuery::getSampleBlockImpl(std::vector> const&, std::shared_ptr const&, std::shared_ptr const&, bool, bool) @ 0x000000001492cf06 5. /build/src/Interpreters/InterpreterInsertQuery.cpp:200: DB::InterpreterInsertQuery::getSampleBlock(DB::ASTInsertQuery const&, std::shared_ptr const&, std::shared_ptr const&, std::shared_ptr, bool, bool) @ 0x000000001492c400 6. /build/src/Interpreters/InterpreterInsertQuery.cpp:838: DB::InterpreterInsertQuery::execute() @ 0x0000000014933ae7 7. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88dc9 8. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 9. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 10. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 11. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 12. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 13. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 14. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 15. ? @ 0x00007fbc6213eac3 16. ? @ 0x00007fbc621d0850 2025.07.28 11:53:44.653863 [ 4581 ] {481dce71-aceb-4eaf-8921-8507540ae67d} executeQuery: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=23, jobs=1): While executing MergeTreeSelect(pool: ReadPoolInOrder, algorithm: InOrder). (CANNOT_SCHEDULE_TASK) (version 25.3.6.10636.altinitytest (altinity build)) (from [::1]:40112) (comment: 02461_mullable_pk_monotonicity_bug.sql) (query 45, line 53) (in query: SELECT x + 1 FROM tab where plus(x, 1) <= toDateTime('2022-02-02') + 2 order by x;), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000fccaeeb 4. /build/src/Common/ThreadPool.cpp:275: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000fccc813 5. /build/src/Common/ThreadPool.cpp:323: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fcc7bbc 6. /build/src/Common/ThreadPool.cpp:494: ThreadPoolImpl>::scheduleOrThrowOnError(std::function, Priority) @ 0x000000000fcc7a0e 7. /build/src/Common/threadPoolCallbackRunner.h:52: std::future> std::__function::__policy_invoker> (DB::MergeTreeMarksLoader::loadMarksAsync()::$_0&&, Priority)>::__call_impl[abi:se190107]> (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&&) @ 0x0000000016474731 8. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000016471940 9. /build/src/Storages/MergeTree/MergeTreeMarksLoader.cpp:83: DB::MergeTreeMarksLoader::startAsyncLoad() @ 0x000000001647173f 10. /build/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) @ 0x000000001648df37 11. /build/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&&) @ 0x00000000163c608d 12. /build/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 @ 0x00000000163c27d4 13. /build/src/Storages/MergeTree/MergeTreeReadTask.cpp:60: DB::MergeTreeReadTask::createReaders(std::shared_ptr const&, DB::MergeTreeReadTask::Extras const&, DB::MarkRanges const&) @ 0x00000000164b5386 14. /build/src/Storages/MergeTree/MergeTreeReadPoolBase.cpp:274: DB::MergeTreeReadPoolBase::createTask(std::shared_ptr, DB::MarkRanges, DB::MergeTreeReadTask*) const @ 0x0000000016e53b1f 15. /build/src/Storages/MergeTree/MergeTreeReadPoolInOrder.cpp:74: DB::MergeTreeReadPoolInOrder::getTask(unsigned long, DB::MergeTreeReadTask*) @ 0x0000000016e7808a 16. /build/src/Storages/MergeTree/MergeTreeSelectProcessor.cpp:191: DB::MergeTreeSelectProcessor::read() @ 0x00000000164c0b40 17. /build/src/Storages/MergeTree/MergeTreeSource.cpp:229: DB::MergeTreeSource::tryGenerate() @ 0x0000000016e43d69 18. /build/src/Processors/ISource.cpp:108: DB::ISource::work() @ 0x00000000169a21e7 19. /build/src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x00000000169bd00f 20. /build/src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x00000000169b2105 21. /build/src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeSingleThread(unsigned long) @ 0x00000000169b23be 22. /build/src/Processors/Executors/PipelineExecutor.cpp:454: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x00000000169b0be7 23. /build/src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x00000000169b03f4 24. /build/src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:se190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169bfeab 25. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc3d92 26. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fcca080 27. ? @ 0x00007fbc6213eac3 28. ? @ 0x00007fbc621d0850 2025.07.28 11:53:44.675371 [ 4581 ] {} TCPHandler: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=23, jobs=1): While executing MergeTreeSelect(pool: ReadPoolInOrder, algorithm: InOrder). (CANNOT_SCHEDULE_TASK), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000fccaeeb 4. /build/src/Common/ThreadPool.cpp:275: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000fccc813 5. /build/src/Common/ThreadPool.cpp:323: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fcc7bbc 6. /build/src/Common/ThreadPool.cpp:494: ThreadPoolImpl>::scheduleOrThrowOnError(std::function, Priority) @ 0x000000000fcc7a0e 7. /build/src/Common/threadPoolCallbackRunner.h:52: std::future> std::__function::__policy_invoker> (DB::MergeTreeMarksLoader::loadMarksAsync()::$_0&&, Priority)>::__call_impl[abi:se190107]> (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&&) @ 0x0000000016474731 8. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000016471940 9. /build/src/Storages/MergeTree/MergeTreeMarksLoader.cpp:83: DB::MergeTreeMarksLoader::startAsyncLoad() @ 0x000000001647173f 10. /build/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) @ 0x000000001648df37 11. /build/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&&) @ 0x00000000163c608d 12. /build/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 @ 0x00000000163c27d4 13. /build/src/Storages/MergeTree/MergeTreeReadTask.cpp:60: DB::MergeTreeReadTask::createReaders(std::shared_ptr const&, DB::MergeTreeReadTask::Extras const&, DB::MarkRanges const&) @ 0x00000000164b5386 14. /build/src/Storages/MergeTree/MergeTreeReadPoolBase.cpp:274: DB::MergeTreeReadPoolBase::createTask(std::shared_ptr, DB::MarkRanges, DB::MergeTreeReadTask*) const @ 0x0000000016e53b1f 15. /build/src/Storages/MergeTree/MergeTreeReadPoolInOrder.cpp:74: DB::MergeTreeReadPoolInOrder::getTask(unsigned long, DB::MergeTreeReadTask*) @ 0x0000000016e7808a 16. /build/src/Storages/MergeTree/MergeTreeSelectProcessor.cpp:191: DB::MergeTreeSelectProcessor::read() @ 0x00000000164c0b40 17. /build/src/Storages/MergeTree/MergeTreeSource.cpp:229: DB::MergeTreeSource::tryGenerate() @ 0x0000000016e43d69 18. /build/src/Processors/ISource.cpp:108: DB::ISource::work() @ 0x00000000169a21e7 19. /build/src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x00000000169bd00f 20. /build/src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x00000000169b2105 21. /build/src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeSingleThread(unsigned long) @ 0x00000000169b23be 22. /build/src/Processors/Executors/PipelineExecutor.cpp:454: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x00000000169b0be7 23. /build/src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x00000000169b03f4 24. /build/src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:se190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169bfeab 25. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc3d92 26. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fcca080 27. ? @ 0x00007fbc6213eac3 28. ? @ 0x00007fbc621d0850 Job's origin stack trace: 0. /build/src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000000fc33b84 1. /build/src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000000fcc2ea7 2. /build/src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fcc535c 3. /build/src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000000fcc584d 4. /build/src/Common/ThreadPool.h:279: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x00000000169bf193 5. /build/src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x00000000169bf518 6. /build/src/Server/TCPHandler.cpp:1237: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x00000000168f1525 7. /build/src/Server/TCPHandler.cpp:678: DB::TCPHandler::runImpl() @ 0x00000000168e68e5 8. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 9. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 10. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 11. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 12. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 13. ? @ 0x00007fbc6213eac3 14. ? @ 0x00007fbc621d0850 2025.07.28 11:53:44.756184 [ 17251 ] {38aaafb6-faa4-4d2f-a1fc-bc304c1cf447} executeQuery: Code: 16. DB::Exception: No such column arr in table test_ixw674u7.t_rename_alter (0f1b84ac-c444-44d8-9e20-952b7b41ef44). (NO_SUCH_COLUMN_IN_TABLE) (version 25.3.6.10636.altinitytest (altinity build)) (from [::1]:45914) (comment: 03352_concurrent_rename_alter.sh) (query 1, line 1) (in query: INSERT INTO t_rename_alter (id, dt, arr) SELECT 1, now(), [(now(), 1, 'a', 'b')]), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x000000000a6a1e2b 4. /build/src/Interpreters/InterpreterInsertQuery.cpp:258: DB::InterpreterInsertQuery::getSampleBlockImpl(std::vector> const&, std::shared_ptr const&, std::shared_ptr const&, bool, bool) @ 0x000000001492cf06 5. /build/src/Interpreters/InterpreterInsertQuery.cpp:200: DB::InterpreterInsertQuery::getSampleBlock(DB::ASTInsertQuery const&, std::shared_ptr const&, std::shared_ptr const&, std::shared_ptr, bool, bool) @ 0x000000001492c400 6. /build/src/Interpreters/InterpreterInsertQuery.cpp:838: DB::InterpreterInsertQuery::execute() @ 0x0000000014933ae7 7. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88dc9 8. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 9. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 10. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 11. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 12. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 13. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 14. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 15. ? @ 0x00007fbc6213eac3 16. ? @ 0x00007fbc621d0850 2025.07.28 11:53:44.768091 [ 17251 ] {} TCPHandler: Code: 16. DB::Exception: No such column arr in table test_ixw674u7.t_rename_alter (0f1b84ac-c444-44d8-9e20-952b7b41ef44). (NO_SUCH_COLUMN_IN_TABLE), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x000000000a6a1e2b 4. /build/src/Interpreters/InterpreterInsertQuery.cpp:258: DB::InterpreterInsertQuery::getSampleBlockImpl(std::vector> const&, std::shared_ptr const&, std::shared_ptr const&, bool, bool) @ 0x000000001492cf06 5. /build/src/Interpreters/InterpreterInsertQuery.cpp:200: DB::InterpreterInsertQuery::getSampleBlock(DB::ASTInsertQuery const&, std::shared_ptr const&, std::shared_ptr const&, std::shared_ptr, bool, bool) @ 0x000000001492c400 6. /build/src/Interpreters/InterpreterInsertQuery.cpp:838: DB::InterpreterInsertQuery::execute() @ 0x0000000014933ae7 7. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88dc9 8. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 9. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 10. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 11. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 12. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 13. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 14. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 15. ? @ 0x00007fbc6213eac3 16. ? @ 0x00007fbc621d0850 2025.07.28 11:53:44.868575 [ 17255 ] {f649bbf5-defd-4bb5-830b-cb7cb1e8eb6d} executeQuery: Code: 16. DB::Exception: No such column arr in table test_ixw674u7.t_rename_alter (0f1b84ac-c444-44d8-9e20-952b7b41ef44). (NO_SUCH_COLUMN_IN_TABLE) (version 25.3.6.10636.altinitytest (altinity build)) (from [::1]:45928) (comment: 03352_concurrent_rename_alter.sh) (query 1, line 1) (in query: INSERT INTO t_rename_alter (id, dt, arr) SELECT 1, now(), [(now(), 1, 'a', 'b')]), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x000000000a6a1e2b 4. /build/src/Interpreters/InterpreterInsertQuery.cpp:258: DB::InterpreterInsertQuery::getSampleBlockImpl(std::vector> const&, std::shared_ptr const&, std::shared_ptr const&, bool, bool) @ 0x000000001492cf06 5. /build/src/Interpreters/InterpreterInsertQuery.cpp:200: DB::InterpreterInsertQuery::getSampleBlock(DB::ASTInsertQuery const&, std::shared_ptr const&, std::shared_ptr const&, std::shared_ptr, bool, bool) @ 0x000000001492c400 6. /build/src/Interpreters/InterpreterInsertQuery.cpp:838: DB::InterpreterInsertQuery::execute() @ 0x0000000014933ae7 7. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88dc9 8. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 9. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 10. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 11. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 12. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 13. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 14. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 15. ? @ 0x00007fbc6213eac3 16. ? @ 0x00007fbc621d0850 2025.07.28 11:53:44.869704 [ 5951 ] {55ff2177-972a-4a1e-be7c-69093218f42f} executeQuery: Code: 16. DB::Exception: No such column arr in table test_ixw674u7.t_rename_alter (0f1b84ac-c444-44d8-9e20-952b7b41ef44). (NO_SUCH_COLUMN_IN_TABLE) (version 25.3.6.10636.altinitytest (altinity build)) (from [::1]:45906) (comment: 03352_concurrent_rename_alter.sh) (query 1, line 1) (in query: INSERT INTO t_rename_alter (id, dt, arr) SELECT 1, now(), [(now(), 1, 'a', 'b')]), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x000000000a6a1e2b 4. /build/src/Interpreters/InterpreterInsertQuery.cpp:258: DB::InterpreterInsertQuery::getSampleBlockImpl(std::vector> const&, std::shared_ptr const&, std::shared_ptr const&, bool, bool) @ 0x000000001492cf06 5. /build/src/Interpreters/InterpreterInsertQuery.cpp:200: DB::InterpreterInsertQuery::getSampleBlock(DB::ASTInsertQuery const&, std::shared_ptr const&, std::shared_ptr const&, std::shared_ptr, bool, bool) @ 0x000000001492c400 6. /build/src/Interpreters/InterpreterInsertQuery.cpp:838: DB::InterpreterInsertQuery::execute() @ 0x0000000014933ae7 7. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88dc9 8. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 9. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 10. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 11. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 12. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 13. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 14. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 15. ? @ 0x00007fbc6213eac3 16. ? @ 0x00007fbc621d0850 2025.07.28 11:53:44.892528 [ 5951 ] {} TCPHandler: Code: 16. DB::Exception: No such column arr in table test_ixw674u7.t_rename_alter (0f1b84ac-c444-44d8-9e20-952b7b41ef44). (NO_SUCH_COLUMN_IN_TABLE), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x000000000a6a1e2b 4. /build/src/Interpreters/InterpreterInsertQuery.cpp:258: DB::InterpreterInsertQuery::getSampleBlockImpl(std::vector> const&, std::shared_ptr const&, std::shared_ptr const&, bool, bool) @ 0x000000001492cf06 5. /build/src/Interpreters/InterpreterInsertQuery.cpp:200: DB::InterpreterInsertQuery::getSampleBlock(DB::ASTInsertQuery const&, std::shared_ptr const&, std::shared_ptr const&, std::shared_ptr, bool, bool) @ 0x000000001492c400 6. /build/src/Interpreters/InterpreterInsertQuery.cpp:838: DB::InterpreterInsertQuery::execute() @ 0x0000000014933ae7 7. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88dc9 8. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 9. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 10. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 11. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 12. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 13. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 14. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 15. ? @ 0x00007fbc6213eac3 16. ? @ 0x00007fbc621d0850 2025.07.28 11:53:44.896776 [ 17255 ] {} TCPHandler: Code: 16. DB::Exception: No such column arr in table test_ixw674u7.t_rename_alter (0f1b84ac-c444-44d8-9e20-952b7b41ef44). (NO_SUCH_COLUMN_IN_TABLE), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x000000000a6a1e2b 4. /build/src/Interpreters/InterpreterInsertQuery.cpp:258: DB::InterpreterInsertQuery::getSampleBlockImpl(std::vector> const&, std::shared_ptr const&, std::shared_ptr const&, bool, bool) @ 0x000000001492cf06 5. /build/src/Interpreters/InterpreterInsertQuery.cpp:200: DB::InterpreterInsertQuery::getSampleBlock(DB::ASTInsertQuery const&, std::shared_ptr const&, std::shared_ptr const&, std::shared_ptr, bool, bool) @ 0x000000001492c400 6. /build/src/Interpreters/InterpreterInsertQuery.cpp:838: DB::InterpreterInsertQuery::execute() @ 0x0000000014933ae7 7. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88dc9 8. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 9. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 10. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 11. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 12. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 13. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 14. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 15. ? @ 0x00007fbc6213eac3 16. ? @ 0x00007fbc621d0850 2025.07.28 11:53:44.902520 [ 3968 ] {} test_13.rmt2 (7f9b740d-015c-470e-8cc6-8ba33be0dc63): auto DB::StorageReplicatedMergeTree::processQueueEntry(ReplicatedMergeTreeQueue::SelectedEntryPtr)::(anonymous class)::operator()(LogEntryPtr &) const: Code: 86. DB::HTTPException: Received error from remote server http://146b4357c08d:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Ftest%2F01165%2Ftest_13%2Frmt%2Freplicas%2F1&part=20250728_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.6.10636.altinitytest (altinity build)) '. (RECEIVED_ERROR_FROM_REMOTE_IO_SERVER), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.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 const&, int&&, String const&, unsigned long&&, String const&) @ 0x000000000feda8d9 4. /build/src/IO/HTTPCommon.cpp:104: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x000000000feda6e2 5. /build/src/IO/HTTPCommon.cpp:93: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x000000000feda537 6. /build/src/IO/ReadWriteBufferFromHTTP.cpp:277: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x000000001184a4c4 7. /build/src/IO/ReadWriteBufferFromHTTP.cpp:285: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x000000001184a615 8. /build/src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x000000001184ae59 9. /build/src/IO/ReadWriteBufferFromHTTP.cpp:472: void std::__function::__policy_invoker::__call_impl[abi:se190107]>(std::__function::__policy_storage const*) @ 0x000000001184cedd 10. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001184858b 11. /build/src/IO/ReadWriteBufferFromHTTP.cpp:465: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x000000001184bf0b 12. /build/src/IO/ReadBuffer.h:60: DB::ReadBuffer::next() @ 0x000000000a148c7b 13. /build/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) @ 0x0000000011849fb2 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]>&)>&, 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&) @ 0x0000000011841980 15. /build/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) @ 0x000000001621208e 16. /build/src/Storages/StorageReplicatedMergeTree.cpp:5228: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl[abi:se190107] const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000015f9a5fe 17. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000015ed8bfd 18. /build/src/Storages/StorageReplicatedMergeTree.cpp:2514: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x0000000015ec9aab 19. /build/src/Storages/StorageReplicatedMergeTree.cpp:2349: DB::StorageReplicatedMergeTree::executeLogEntry(DB::ReplicatedMergeTreeLogEntry&) @ 0x0000000015eba91b 20. /build/src/Storages/StorageReplicatedMergeTree.cpp:3876: bool std::__function::__policy_invoker&)>::__call_impl[abi:se190107])::$_1, bool (std::shared_ptr&)>>(std::__function::__policy_storage const*, std::shared_ptr&) @ 0x0000000015f9837e 21. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000165d6fc3 22. /build/src/Storages/StorageReplicatedMergeTree.cpp:3872: DB::StorageReplicatedMergeTree::processQueueEntry(std::shared_ptr) @ 0x0000000015efc18a 23. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001624c1b2 24. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000162f9c70 25. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x00000000162fa55a 26. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc6653 27. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000000fccc4c3 28. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc3d92 29. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fcca080 30. ? @ 0x00007fbc6213eac3 31. ? @ 0x00007fbc621d0850 (version 25.3.6.10636.altinitytest (altinity build)) 2025.07.28 11:53:45.004761 [ 11826 ] {ec2eadc3-098e-4d05-94b0-ab5b59edf1f6} executeQuery: Code: 16. DB::Exception: No such column arr in table test_ixw674u7.t_rename_alter (0f1b84ac-c444-44d8-9e20-952b7b41ef44). (NO_SUCH_COLUMN_IN_TABLE) (version 25.3.6.10636.altinitytest (altinity build)) (from [::1]:46012) (comment: 03352_concurrent_rename_alter.sh) (query 1, line 1) (in query: INSERT INTO t_rename_alter (id, dt, arr) SELECT 1, now(), [(now(), 1, 'a', 'b')]), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x000000000a6a1e2b 4. /build/src/Interpreters/InterpreterInsertQuery.cpp:258: DB::InterpreterInsertQuery::getSampleBlockImpl(std::vector> const&, std::shared_ptr const&, std::shared_ptr const&, bool, bool) @ 0x000000001492cf06 5. /build/src/Interpreters/InterpreterInsertQuery.cpp:200: DB::InterpreterInsertQuery::getSampleBlock(DB::ASTInsertQuery const&, std::shared_ptr const&, std::shared_ptr const&, std::shared_ptr, bool, bool) @ 0x000000001492c400 6. /build/src/Interpreters/InterpreterInsertQuery.cpp:838: DB::InterpreterInsertQuery::execute() @ 0x0000000014933ae7 7. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88dc9 8. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 9. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 10. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 11. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 12. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 13. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 14. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 15. ? @ 0x00007fbc6213eac3 16. ? @ 0x00007fbc621d0850 2025.07.28 11:53:45.019335 [ 17371 ] {028e18b9-4490-4d3d-8070-6e63ec79899d} executeQuery: Code: 16. DB::Exception: No such column arr in table test_ixw674u7.t_rename_alter (0f1b84ac-c444-44d8-9e20-952b7b41ef44). (NO_SUCH_COLUMN_IN_TABLE) (version 25.3.6.10636.altinitytest (altinity build)) (from [::1]:46020) (comment: 03352_concurrent_rename_alter.sh) (query 1, line 1) (in query: INSERT INTO t_rename_alter (id, dt, arr) SELECT 1, now(), [(now(), 1, 'a', 'b')]), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x000000000a6a1e2b 4. /build/src/Interpreters/InterpreterInsertQuery.cpp:258: DB::InterpreterInsertQuery::getSampleBlockImpl(std::vector> const&, std::shared_ptr const&, std::shared_ptr const&, bool, bool) @ 0x000000001492cf06 5. /build/src/Interpreters/InterpreterInsertQuery.cpp:200: DB::InterpreterInsertQuery::getSampleBlock(DB::ASTInsertQuery const&, std::shared_ptr const&, std::shared_ptr const&, std::shared_ptr, bool, bool) @ 0x000000001492c400 6. /build/src/Interpreters/InterpreterInsertQuery.cpp:838: DB::InterpreterInsertQuery::execute() @ 0x0000000014933ae7 7. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88dc9 8. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 9. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 10. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 11. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 12. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 13. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 14. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 15. ? @ 0x00007fbc6213eac3 16. ? @ 0x00007fbc621d0850 2025.07.28 11:53:45.027821 [ 11826 ] {} TCPHandler: Code: 16. DB::Exception: No such column arr in table test_ixw674u7.t_rename_alter (0f1b84ac-c444-44d8-9e20-952b7b41ef44). (NO_SUCH_COLUMN_IN_TABLE), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x000000000a6a1e2b 4. /build/src/Interpreters/InterpreterInsertQuery.cpp:258: DB::InterpreterInsertQuery::getSampleBlockImpl(std::vector> const&, std::shared_ptr const&, std::shared_ptr const&, bool, bool) @ 0x000000001492cf06 5. /build/src/Interpreters/InterpreterInsertQuery.cpp:200: DB::InterpreterInsertQuery::getSampleBlock(DB::ASTInsertQuery const&, std::shared_ptr const&, std::shared_ptr const&, std::shared_ptr, bool, bool) @ 0x000000001492c400 6. /build/src/Interpreters/InterpreterInsertQuery.cpp:838: DB::InterpreterInsertQuery::execute() @ 0x0000000014933ae7 7. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88dc9 8. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 9. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 10. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 11. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 12. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 13. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 14. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 15. ? @ 0x00007fbc6213eac3 16. ? @ 0x00007fbc621d0850 2025.07.28 11:53:45.093914 [ 17371 ] {} TCPHandler: Code: 16. DB::Exception: No such column arr in table test_ixw674u7.t_rename_alter (0f1b84ac-c444-44d8-9e20-952b7b41ef44). (NO_SUCH_COLUMN_IN_TABLE), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x000000000a6a1e2b 4. /build/src/Interpreters/InterpreterInsertQuery.cpp:258: DB::InterpreterInsertQuery::getSampleBlockImpl(std::vector> const&, std::shared_ptr const&, std::shared_ptr const&, bool, bool) @ 0x000000001492cf06 5. /build/src/Interpreters/InterpreterInsertQuery.cpp:200: DB::InterpreterInsertQuery::getSampleBlock(DB::ASTInsertQuery const&, std::shared_ptr const&, std::shared_ptr const&, std::shared_ptr, bool, bool) @ 0x000000001492c400 6. /build/src/Interpreters/InterpreterInsertQuery.cpp:838: DB::InterpreterInsertQuery::execute() @ 0x0000000014933ae7 7. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88dc9 8. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 9. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 10. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 11. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 12. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 13. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 14. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 15. ? @ 0x00007fbc6213eac3 16. ? @ 0x00007fbc621d0850 2025.07.28 11:53:45.141122 [ 17252 ] {7f7a2891-f584-4be9-bc03-424bf644ddd6} executeQuery: Code: 16. DB::Exception: No such column arr in table test_ixw674u7.t_rename_alter (0f1b84ac-c444-44d8-9e20-952b7b41ef44). (NO_SUCH_COLUMN_IN_TABLE) (version 25.3.6.10636.altinitytest (altinity build)) (from [::1]:46030) (comment: 03352_concurrent_rename_alter.sh) (query 1, line 1) (in query: INSERT INTO t_rename_alter (id, dt, arr) SELECT 1, now(), [(now(), 1, 'a', 'b')]), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x000000000a6a1e2b 4. /build/src/Interpreters/InterpreterInsertQuery.cpp:258: DB::InterpreterInsertQuery::getSampleBlockImpl(std::vector> const&, std::shared_ptr const&, std::shared_ptr const&, bool, bool) @ 0x000000001492cf06 5. /build/src/Interpreters/InterpreterInsertQuery.cpp:200: DB::InterpreterInsertQuery::getSampleBlock(DB::ASTInsertQuery const&, std::shared_ptr const&, std::shared_ptr const&, std::shared_ptr, bool, bool) @ 0x000000001492c400 6. /build/src/Interpreters/InterpreterInsertQuery.cpp:838: DB::InterpreterInsertQuery::execute() @ 0x0000000014933ae7 7. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88dc9 8. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 9. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 10. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 11. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 12. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 13. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 14. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 15. ? @ 0x00007fbc6213eac3 16. ? @ 0x00007fbc621d0850 2025.07.28 11:53:45.151401 [ 17252 ] {} TCPHandler: Code: 16. DB::Exception: No such column arr in table test_ixw674u7.t_rename_alter (0f1b84ac-c444-44d8-9e20-952b7b41ef44). (NO_SUCH_COLUMN_IN_TABLE), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x000000000a6a1e2b 4. /build/src/Interpreters/InterpreterInsertQuery.cpp:258: DB::InterpreterInsertQuery::getSampleBlockImpl(std::vector> const&, std::shared_ptr const&, std::shared_ptr const&, bool, bool) @ 0x000000001492cf06 5. /build/src/Interpreters/InterpreterInsertQuery.cpp:200: DB::InterpreterInsertQuery::getSampleBlock(DB::ASTInsertQuery const&, std::shared_ptr const&, std::shared_ptr const&, std::shared_ptr, bool, bool) @ 0x000000001492c400 6. /build/src/Interpreters/InterpreterInsertQuery.cpp:838: DB::InterpreterInsertQuery::execute() @ 0x0000000014933ae7 7. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88dc9 8. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 9. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 10. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 11. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 12. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 13. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 14. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 15. ? @ 0x00007fbc6213eac3 16. ? @ 0x00007fbc621d0850 2025.07.28 11:53:45.214405 [ 17557 ] {93343384-113d-4f40-8abd-0f6c4456081e} executeQuery: Code: 16. DB::Exception: No such column arr in table test_ixw674u7.t_rename_alter (0f1b84ac-c444-44d8-9e20-952b7b41ef44). (NO_SUCH_COLUMN_IN_TABLE) (version 25.3.6.10636.altinitytest (altinity build)) (from [::1]:46066) (comment: 03352_concurrent_rename_alter.sh) (query 1, line 1) (in query: INSERT INTO t_rename_alter (id, dt, arr) SELECT 1, now(), [(now(), 1, 'a', 'b')]), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x000000000a6a1e2b 4. /build/src/Interpreters/InterpreterInsertQuery.cpp:258: DB::InterpreterInsertQuery::getSampleBlockImpl(std::vector> const&, std::shared_ptr const&, std::shared_ptr const&, bool, bool) @ 0x000000001492cf06 5. /build/src/Interpreters/InterpreterInsertQuery.cpp:200: DB::InterpreterInsertQuery::getSampleBlock(DB::ASTInsertQuery const&, std::shared_ptr const&, std::shared_ptr const&, std::shared_ptr, bool, bool) @ 0x000000001492c400 6. /build/src/Interpreters/InterpreterInsertQuery.cpp:838: DB::InterpreterInsertQuery::execute() @ 0x0000000014933ae7 7. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88dc9 8. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 9. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 10. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 11. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 12. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 13. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 14. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 15. ? @ 0x00007fbc6213eac3 16. ? @ 0x00007fbc621d0850 2025.07.28 11:53:45.223451 [ 11826 ] {ad98e6d3-98a5-4bd2-a41b-a184e97c5f2f} executeQuery: Code: 16. DB::Exception: No such column arr in table test_ixw674u7.t_rename_alter (0f1b84ac-c444-44d8-9e20-952b7b41ef44). (NO_SUCH_COLUMN_IN_TABLE) (version 25.3.6.10636.altinitytest (altinity build)) (from [::1]:46076) (comment: 03352_concurrent_rename_alter.sh) (query 1, line 1) (in query: INSERT INTO t_rename_alter (id, dt, arr) SELECT 1, now(), [(now(), 1, 'a', 'b')]), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x000000000a6a1e2b 4. /build/src/Interpreters/InterpreterInsertQuery.cpp:258: DB::InterpreterInsertQuery::getSampleBlockImpl(std::vector> const&, std::shared_ptr const&, std::shared_ptr const&, bool, bool) @ 0x000000001492cf06 5. /build/src/Interpreters/InterpreterInsertQuery.cpp:200: DB::InterpreterInsertQuery::getSampleBlock(DB::ASTInsertQuery const&, std::shared_ptr const&, std::shared_ptr const&, std::shared_ptr, bool, bool) @ 0x000000001492c400 6. /build/src/Interpreters/InterpreterInsertQuery.cpp:838: DB::InterpreterInsertQuery::execute() @ 0x0000000014933ae7 7. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88dc9 8. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 9. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 10. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 11. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 12. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 13. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 14. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 15. ? @ 0x00007fbc6213eac3 16. ? @ 0x00007fbc621d0850 2025.07.28 11:53:45.281863 [ 11826 ] {} TCPHandler: Code: 16. DB::Exception: No such column arr in table test_ixw674u7.t_rename_alter (0f1b84ac-c444-44d8-9e20-952b7b41ef44). (NO_SUCH_COLUMN_IN_TABLE), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x000000000a6a1e2b 4. /build/src/Interpreters/InterpreterInsertQuery.cpp:258: DB::InterpreterInsertQuery::getSampleBlockImpl(std::vector> const&, std::shared_ptr const&, std::shared_ptr const&, bool, bool) @ 0x000000001492cf06 5. /build/src/Interpreters/InterpreterInsertQuery.cpp:200: DB::InterpreterInsertQuery::getSampleBlock(DB::ASTInsertQuery const&, std::shared_ptr const&, std::shared_ptr const&, std::shared_ptr, bool, bool) @ 0x000000001492c400 6. /build/src/Interpreters/InterpreterInsertQuery.cpp:838: DB::InterpreterInsertQuery::execute() @ 0x0000000014933ae7 7. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88dc9 8. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 9. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 10. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 11. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 12. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 13. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 14. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 15. ? @ 0x00007fbc6213eac3 16. ? @ 0x00007fbc621d0850 2025.07.28 11:53:45.282998 [ 17557 ] {} TCPHandler: Code: 16. DB::Exception: No such column arr in table test_ixw674u7.t_rename_alter (0f1b84ac-c444-44d8-9e20-952b7b41ef44). (NO_SUCH_COLUMN_IN_TABLE), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x000000000a6a1e2b 4. /build/src/Interpreters/InterpreterInsertQuery.cpp:258: DB::InterpreterInsertQuery::getSampleBlockImpl(std::vector> const&, std::shared_ptr const&, std::shared_ptr const&, bool, bool) @ 0x000000001492cf06 5. /build/src/Interpreters/InterpreterInsertQuery.cpp:200: DB::InterpreterInsertQuery::getSampleBlock(DB::ASTInsertQuery const&, std::shared_ptr const&, std::shared_ptr const&, std::shared_ptr, bool, bool) @ 0x000000001492c400 6. /build/src/Interpreters/InterpreterInsertQuery.cpp:838: DB::InterpreterInsertQuery::execute() @ 0x0000000014933ae7 7. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88dc9 8. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 9. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 10. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 11. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 12. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 13. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 14. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 15. ? @ 0x00007fbc6213eac3 16. ? @ 0x00007fbc621d0850 2025.07.28 11:53:45.356556 [ 5825 ] {c0c9a087-4ab2-4038-bf91-b0db7c0780d9} executeQuery: Code: 16. DB::Exception: No such column arr in table test_ixw674u7.t_rename_alter (0f1b84ac-c444-44d8-9e20-952b7b41ef44). (NO_SUCH_COLUMN_IN_TABLE) (version 25.3.6.10636.altinitytest (altinity build)) (from [::1]:46122) (comment: 03352_concurrent_rename_alter.sh) (query 1, line 1) (in query: INSERT INTO t_rename_alter (id, dt, arr) SELECT 1, now(), [(now(), 1, 'a', 'b')]), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x000000000a6a1e2b 4. /build/src/Interpreters/InterpreterInsertQuery.cpp:258: DB::InterpreterInsertQuery::getSampleBlockImpl(std::vector> const&, std::shared_ptr const&, std::shared_ptr const&, bool, bool) @ 0x000000001492cf06 5. /build/src/Interpreters/InterpreterInsertQuery.cpp:200: DB::InterpreterInsertQuery::getSampleBlock(DB::ASTInsertQuery const&, std::shared_ptr const&, std::shared_ptr const&, std::shared_ptr, bool, bool) @ 0x000000001492c400 6. /build/src/Interpreters/InterpreterInsertQuery.cpp:838: DB::InterpreterInsertQuery::execute() @ 0x0000000014933ae7 7. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88dc9 8. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 9. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 10. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 11. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 12. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 13. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 14. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 15. ? @ 0x00007fbc6213eac3 16. ? @ 0x00007fbc621d0850 2025.07.28 11:53:45.364303 [ 5825 ] {} TCPHandler: Code: 16. DB::Exception: No such column arr in table test_ixw674u7.t_rename_alter (0f1b84ac-c444-44d8-9e20-952b7b41ef44). (NO_SUCH_COLUMN_IN_TABLE), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x000000000a6a1e2b 4. /build/src/Interpreters/InterpreterInsertQuery.cpp:258: DB::InterpreterInsertQuery::getSampleBlockImpl(std::vector> const&, std::shared_ptr const&, std::shared_ptr const&, bool, bool) @ 0x000000001492cf06 5. /build/src/Interpreters/InterpreterInsertQuery.cpp:200: DB::InterpreterInsertQuery::getSampleBlock(DB::ASTInsertQuery const&, std::shared_ptr const&, std::shared_ptr const&, std::shared_ptr, bool, bool) @ 0x000000001492c400 6. /build/src/Interpreters/InterpreterInsertQuery.cpp:838: DB::InterpreterInsertQuery::execute() @ 0x0000000014933ae7 7. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88dc9 8. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 9. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 10. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 11. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 12. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 13. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 14. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 15. ? @ 0x00007fbc6213eac3 16. ? @ 0x00007fbc621d0850 2025.07.28 11:53:45.387716 [ 3970 ] {} test_13.rmt2 (7f9b740d-015c-470e-8cc6-8ba33be0dc63): auto DB::StorageReplicatedMergeTree::processQueueEntry(ReplicatedMergeTreeQueue::SelectedEntryPtr)::(anonymous class)::operator()(LogEntryPtr &) const: Code: 86. DB::HTTPException: Received error from remote server http://146b4357c08d:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Ftest%2F01165%2Ftest_13%2Frmt%2Freplicas%2F1&part=20250728_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.6.10636.altinitytest (altinity build)) '. (RECEIVED_ERROR_FROM_REMOTE_IO_SERVER), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.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 const&, int&&, String const&, unsigned long&&, String const&) @ 0x000000000feda8d9 4. /build/src/IO/HTTPCommon.cpp:104: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x000000000feda6e2 5. /build/src/IO/HTTPCommon.cpp:93: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x000000000feda537 6. /build/src/IO/ReadWriteBufferFromHTTP.cpp:277: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x000000001184a4c4 7. /build/src/IO/ReadWriteBufferFromHTTP.cpp:285: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x000000001184a615 8. /build/src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x000000001184ae59 9. /build/src/IO/ReadWriteBufferFromHTTP.cpp:472: void std::__function::__policy_invoker::__call_impl[abi:se190107]>(std::__function::__policy_storage const*) @ 0x000000001184cedd 10. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001184858b 11. /build/src/IO/ReadWriteBufferFromHTTP.cpp:465: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x000000001184bf0b 12. /build/src/IO/ReadBuffer.h:60: DB::ReadBuffer::next() @ 0x000000000a148c7b 13. /build/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) @ 0x0000000011849fb2 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]>&)>&, 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&) @ 0x0000000011841980 15. /build/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) @ 0x000000001621208e 16. /build/src/Storages/StorageReplicatedMergeTree.cpp:5228: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl[abi:se190107] const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000015f9a5fe 17. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000015ed8bfd 18. /build/src/Storages/StorageReplicatedMergeTree.cpp:2514: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x0000000015ec9aab 19. /build/src/Storages/StorageReplicatedMergeTree.cpp:2349: DB::StorageReplicatedMergeTree::executeLogEntry(DB::ReplicatedMergeTreeLogEntry&) @ 0x0000000015eba91b 20. /build/src/Storages/StorageReplicatedMergeTree.cpp:3876: bool std::__function::__policy_invoker&)>::__call_impl[abi:se190107])::$_1, bool (std::shared_ptr&)>>(std::__function::__policy_storage const*, std::shared_ptr&) @ 0x0000000015f9837e 21. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000165d6fc3 22. /build/src/Storages/StorageReplicatedMergeTree.cpp:3872: DB::StorageReplicatedMergeTree::processQueueEntry(std::shared_ptr) @ 0x0000000015efc18a 23. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001624c1b2 24. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000162f9c70 25. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x00000000162fa55a 26. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc6653 27. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000000fccc4c3 28. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc3d92 29. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fcca080 30. ? @ 0x00007fbc6213eac3 31. ? @ 0x00007fbc621d0850 (version 25.3.6.10636.altinitytest (altinity build)) 2025.07.28 11:53:45.431412 [ 17203 ] {3ee5a86b-12e9-4637-9c64-b22b1d7e7a4b} executeQuery: Code: 16. DB::Exception: No such column arr in table test_ixw674u7.t_rename_alter (0f1b84ac-c444-44d8-9e20-952b7b41ef44). (NO_SUCH_COLUMN_IN_TABLE) (version 25.3.6.10636.altinitytest (altinity build)) (from [::1]:46136) (comment: 03352_concurrent_rename_alter.sh) (query 1, line 1) (in query: INSERT INTO t_rename_alter (id, dt, arr) SELECT 1, now(), [(now(), 1, 'a', 'b')]), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x000000000a6a1e2b 4. /build/src/Interpreters/InterpreterInsertQuery.cpp:258: DB::InterpreterInsertQuery::getSampleBlockImpl(std::vector> const&, std::shared_ptr const&, std::shared_ptr const&, bool, bool) @ 0x000000001492cf06 5. /build/src/Interpreters/InterpreterInsertQuery.cpp:200: DB::InterpreterInsertQuery::getSampleBlock(DB::ASTInsertQuery const&, std::shared_ptr const&, std::shared_ptr const&, std::shared_ptr, bool, bool) @ 0x000000001492c400 6. /build/src/Interpreters/InterpreterInsertQuery.cpp:838: DB::InterpreterInsertQuery::execute() @ 0x0000000014933ae7 7. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88dc9 8. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 9. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 10. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 11. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 12. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 13. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 14. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 15. ? @ 0x00007fbc6213eac3 16. ? @ 0x00007fbc621d0850 2025.07.28 11:53:45.440023 [ 17203 ] {} TCPHandler: Code: 16. DB::Exception: No such column arr in table test_ixw674u7.t_rename_alter (0f1b84ac-c444-44d8-9e20-952b7b41ef44). (NO_SUCH_COLUMN_IN_TABLE), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x000000000a6a1e2b 4. /build/src/Interpreters/InterpreterInsertQuery.cpp:258: DB::InterpreterInsertQuery::getSampleBlockImpl(std::vector> const&, std::shared_ptr const&, std::shared_ptr const&, bool, bool) @ 0x000000001492cf06 5. /build/src/Interpreters/InterpreterInsertQuery.cpp:200: DB::InterpreterInsertQuery::getSampleBlock(DB::ASTInsertQuery const&, std::shared_ptr const&, std::shared_ptr const&, std::shared_ptr, bool, bool) @ 0x000000001492c400 6. /build/src/Interpreters/InterpreterInsertQuery.cpp:838: DB::InterpreterInsertQuery::execute() @ 0x0000000014933ae7 7. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88dc9 8. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 9. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 10. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 11. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 12. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 13. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 14. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 15. ? @ 0x00007fbc6213eac3 16. ? @ 0x00007fbc621d0850 2025.07.28 11:53:45.487403 [ 17557 ] {891f0d15-0724-4bf3-85ae-22d2f47eb9b7} executeQuery: Code: 16. DB::Exception: No such column arr in table test_ixw674u7.t_rename_alter (0f1b84ac-c444-44d8-9e20-952b7b41ef44). (NO_SUCH_COLUMN_IN_TABLE) (version 25.3.6.10636.altinitytest (altinity build)) (from [::1]:46138) (comment: 03352_concurrent_rename_alter.sh) (query 1, line 1) (in query: INSERT INTO t_rename_alter (id, dt, arr) SELECT 1, now(), [(now(), 1, 'a', 'b')]), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x000000000a6a1e2b 4. /build/src/Interpreters/InterpreterInsertQuery.cpp:258: DB::InterpreterInsertQuery::getSampleBlockImpl(std::vector> const&, std::shared_ptr const&, std::shared_ptr const&, bool, bool) @ 0x000000001492cf06 5. /build/src/Interpreters/InterpreterInsertQuery.cpp:200: DB::InterpreterInsertQuery::getSampleBlock(DB::ASTInsertQuery const&, std::shared_ptr const&, std::shared_ptr const&, std::shared_ptr, bool, bool) @ 0x000000001492c400 6. /build/src/Interpreters/InterpreterInsertQuery.cpp:838: DB::InterpreterInsertQuery::execute() @ 0x0000000014933ae7 7. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88dc9 8. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 9. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 10. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 11. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 12. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 13. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 14. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 15. ? @ 0x00007fbc6213eac3 16. ? @ 0x00007fbc621d0850 2025.07.28 11:53:45.509772 [ 17557 ] {} TCPHandler: Code: 16. DB::Exception: No such column arr in table test_ixw674u7.t_rename_alter (0f1b84ac-c444-44d8-9e20-952b7b41ef44). (NO_SUCH_COLUMN_IN_TABLE), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x000000000a6a1e2b 4. /build/src/Interpreters/InterpreterInsertQuery.cpp:258: DB::InterpreterInsertQuery::getSampleBlockImpl(std::vector> const&, std::shared_ptr const&, std::shared_ptr const&, bool, bool) @ 0x000000001492cf06 5. /build/src/Interpreters/InterpreterInsertQuery.cpp:200: DB::InterpreterInsertQuery::getSampleBlock(DB::ASTInsertQuery const&, std::shared_ptr const&, std::shared_ptr const&, std::shared_ptr, bool, bool) @ 0x000000001492c400 6. /build/src/Interpreters/InterpreterInsertQuery.cpp:838: DB::InterpreterInsertQuery::execute() @ 0x0000000014933ae7 7. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88dc9 8. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 9. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 10. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 11. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 12. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 13. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 14. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 15. ? @ 0x00007fbc6213eac3 16. ? @ 0x00007fbc621d0850 2025.07.28 11:53:45.691690 [ 17371 ] {faf73d53-99d9-4a5f-aec5-3a640b32f896} executeQuery: Code: 16. DB::Exception: No such column arr in table test_ixw674u7.t_rename_alter (0f1b84ac-c444-44d8-9e20-952b7b41ef44). (NO_SUCH_COLUMN_IN_TABLE) (version 25.3.6.10636.altinitytest (altinity build)) (from [::1]:46168) (comment: 03352_concurrent_rename_alter.sh) (query 1, line 1) (in query: INSERT INTO t_rename_alter (id, dt, arr) SELECT 1, now(), [(now(), 1, 'a', 'b')]), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x000000000a6a1e2b 4. /build/src/Interpreters/InterpreterInsertQuery.cpp:258: DB::InterpreterInsertQuery::getSampleBlockImpl(std::vector> const&, std::shared_ptr const&, std::shared_ptr const&, bool, bool) @ 0x000000001492cf06 5. /build/src/Interpreters/InterpreterInsertQuery.cpp:200: DB::InterpreterInsertQuery::getSampleBlock(DB::ASTInsertQuery const&, std::shared_ptr const&, std::shared_ptr const&, std::shared_ptr, bool, bool) @ 0x000000001492c400 6. /build/src/Interpreters/InterpreterInsertQuery.cpp:838: DB::InterpreterInsertQuery::execute() @ 0x0000000014933ae7 7. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88dc9 8. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 9. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 10. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 11. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 12. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 13. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 14. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 15. ? @ 0x00007fbc6213eac3 16. ? @ 0x00007fbc621d0850 2025.07.28 11:53:45.698111 [ 17252 ] {95559126-216f-4aff-9a53-0a0246408b49} executeQuery: Code: 16. DB::Exception: No such column arr in table test_ixw674u7.t_rename_alter (0f1b84ac-c444-44d8-9e20-952b7b41ef44). (NO_SUCH_COLUMN_IN_TABLE) (version 25.3.6.10636.altinitytest (altinity build)) (from [::1]:46176) (comment: 03352_concurrent_rename_alter.sh) (query 1, line 1) (in query: INSERT INTO t_rename_alter (id, dt, arr) SELECT 1, now(), [(now(), 1, 'a', 'b')]), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x000000000a6a1e2b 4. /build/src/Interpreters/InterpreterInsertQuery.cpp:258: DB::InterpreterInsertQuery::getSampleBlockImpl(std::vector> const&, std::shared_ptr const&, std::shared_ptr const&, bool, bool) @ 0x000000001492cf06 5. /build/src/Interpreters/InterpreterInsertQuery.cpp:200: DB::InterpreterInsertQuery::getSampleBlock(DB::ASTInsertQuery const&, std::shared_ptr const&, std::shared_ptr const&, std::shared_ptr, bool, bool) @ 0x000000001492c400 6. /build/src/Interpreters/InterpreterInsertQuery.cpp:838: DB::InterpreterInsertQuery::execute() @ 0x0000000014933ae7 7. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88dc9 8. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 9. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 10. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 11. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 12. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 13. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 14. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 15. ? @ 0x00007fbc6213eac3 16. ? @ 0x00007fbc621d0850 2025.07.28 11:53:45.704669 [ 17371 ] {} TCPHandler: Code: 16. DB::Exception: No such column arr in table test_ixw674u7.t_rename_alter (0f1b84ac-c444-44d8-9e20-952b7b41ef44). (NO_SUCH_COLUMN_IN_TABLE), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x000000000a6a1e2b 4. /build/src/Interpreters/InterpreterInsertQuery.cpp:258: DB::InterpreterInsertQuery::getSampleBlockImpl(std::vector> const&, std::shared_ptr const&, std::shared_ptr const&, bool, bool) @ 0x000000001492cf06 5. /build/src/Interpreters/InterpreterInsertQuery.cpp:200: DB::InterpreterInsertQuery::getSampleBlock(DB::ASTInsertQuery const&, std::shared_ptr const&, std::shared_ptr const&, std::shared_ptr, bool, bool) @ 0x000000001492c400 6. /build/src/Interpreters/InterpreterInsertQuery.cpp:838: DB::InterpreterInsertQuery::execute() @ 0x0000000014933ae7 7. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88dc9 8. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 9. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 10. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 11. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 12. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 13. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 14. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 15. ? @ 0x00007fbc6213eac3 16. ? @ 0x00007fbc621d0850 2025.07.28 11:53:45.717309 [ 17252 ] {} TCPHandler: Code: 16. DB::Exception: No such column arr in table test_ixw674u7.t_rename_alter (0f1b84ac-c444-44d8-9e20-952b7b41ef44). (NO_SUCH_COLUMN_IN_TABLE), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x000000000a6a1e2b 4. /build/src/Interpreters/InterpreterInsertQuery.cpp:258: DB::InterpreterInsertQuery::getSampleBlockImpl(std::vector> const&, std::shared_ptr const&, std::shared_ptr const&, bool, bool) @ 0x000000001492cf06 5. /build/src/Interpreters/InterpreterInsertQuery.cpp:200: DB::InterpreterInsertQuery::getSampleBlock(DB::ASTInsertQuery const&, std::shared_ptr const&, std::shared_ptr const&, std::shared_ptr, bool, bool) @ 0x000000001492c400 6. /build/src/Interpreters/InterpreterInsertQuery.cpp:838: DB::InterpreterInsertQuery::execute() @ 0x0000000014933ae7 7. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88dc9 8. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 9. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 10. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 11. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 12. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 13. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 14. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 15. ? @ 0x00007fbc6213eac3 16. ? @ 0x00007fbc621d0850 2025.07.28 11:53:45.722457 [ 12807 ] {4d72b3c7-d5c5-4db9-a9f7-cb7a70e476b8} executeQuery: Code: 16. DB::Exception: No such column arr in table test_ixw674u7.t_rename_alter (0f1b84ac-c444-44d8-9e20-952b7b41ef44). (NO_SUCH_COLUMN_IN_TABLE) (version 25.3.6.10636.altinitytest (altinity build)) (from [::1]:46190) (comment: 03352_concurrent_rename_alter.sh) (query 1, line 1) (in query: INSERT INTO t_rename_alter (id, dt, arr) SELECT 1, now(), [(now(), 1, 'a', 'b')]), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x000000000a6a1e2b 4. /build/src/Interpreters/InterpreterInsertQuery.cpp:258: DB::InterpreterInsertQuery::getSampleBlockImpl(std::vector> const&, std::shared_ptr const&, std::shared_ptr const&, bool, bool) @ 0x000000001492cf06 5. /build/src/Interpreters/InterpreterInsertQuery.cpp:200: DB::InterpreterInsertQuery::getSampleBlock(DB::ASTInsertQuery const&, std::shared_ptr const&, std::shared_ptr const&, std::shared_ptr, bool, bool) @ 0x000000001492c400 6. /build/src/Interpreters/InterpreterInsertQuery.cpp:838: DB::InterpreterInsertQuery::execute() @ 0x0000000014933ae7 7. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88dc9 8. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 9. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 10. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 11. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 12. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 13. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 14. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 15. ? @ 0x00007fbc6213eac3 16. ? @ 0x00007fbc621d0850 2025.07.28 11:53:45.731692 [ 12807 ] {} TCPHandler: Code: 16. DB::Exception: No such column arr in table test_ixw674u7.t_rename_alter (0f1b84ac-c444-44d8-9e20-952b7b41ef44). (NO_SUCH_COLUMN_IN_TABLE), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x000000000a6a1e2b 4. /build/src/Interpreters/InterpreterInsertQuery.cpp:258: DB::InterpreterInsertQuery::getSampleBlockImpl(std::vector> const&, std::shared_ptr const&, std::shared_ptr const&, bool, bool) @ 0x000000001492cf06 5. /build/src/Interpreters/InterpreterInsertQuery.cpp:200: DB::InterpreterInsertQuery::getSampleBlock(DB::ASTInsertQuery const&, std::shared_ptr const&, std::shared_ptr const&, std::shared_ptr, bool, bool) @ 0x000000001492c400 6. /build/src/Interpreters/InterpreterInsertQuery.cpp:838: DB::InterpreterInsertQuery::execute() @ 0x0000000014933ae7 7. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88dc9 8. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 9. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 10. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 11. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 12. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 13. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 14. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 15. ? @ 0x00007fbc6213eac3 16. ? @ 0x00007fbc621d0850 2025.07.28 11:53:45.853766 [ 5327 ] {0a18ce78-1ea8-4881-8d1d-d0b509d324bb} executeQuery: Code: 16. DB::Exception: No such column arr in table test_ixw674u7.t_rename_alter (0f1b84ac-c444-44d8-9e20-952b7b41ef44). (NO_SUCH_COLUMN_IN_TABLE) (version 25.3.6.10636.altinitytest (altinity build)) (from [::1]:46228) (comment: 03352_concurrent_rename_alter.sh) (query 1, line 1) (in query: INSERT INTO t_rename_alter (id, dt, arr) SELECT 1, now(), [(now(), 1, 'a', 'b')]), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x000000000a6a1e2b 4. /build/src/Interpreters/InterpreterInsertQuery.cpp:258: DB::InterpreterInsertQuery::getSampleBlockImpl(std::vector> const&, std::shared_ptr const&, std::shared_ptr const&, bool, bool) @ 0x000000001492cf06 5. /build/src/Interpreters/InterpreterInsertQuery.cpp:200: DB::InterpreterInsertQuery::getSampleBlock(DB::ASTInsertQuery const&, std::shared_ptr const&, std::shared_ptr const&, std::shared_ptr, bool, bool) @ 0x000000001492c400 6. /build/src/Interpreters/InterpreterInsertQuery.cpp:838: DB::InterpreterInsertQuery::execute() @ 0x0000000014933ae7 7. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88dc9 8. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 9. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 10. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 11. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 12. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 13. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 14. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 15. ? @ 0x00007fbc6213eac3 16. ? @ 0x00007fbc621d0850 2025.07.28 11:53:45.870214 [ 17208 ] {f563f7a2-928a-4e05-8b52-1b1b769ca58b} executeQuery: Code: 16. DB::Exception: No such column arr in table test_ixw674u7.t_rename_alter (0f1b84ac-c444-44d8-9e20-952b7b41ef44). (NO_SUCH_COLUMN_IN_TABLE) (version 25.3.6.10636.altinitytest (altinity build)) (from [::1]:46238) (comment: 03352_concurrent_rename_alter.sh) (query 1, line 1) (in query: INSERT INTO t_rename_alter (id, dt, arr) SELECT 1, now(), [(now(), 1, 'a', 'b')]), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x000000000a6a1e2b 4. /build/src/Interpreters/InterpreterInsertQuery.cpp:258: DB::InterpreterInsertQuery::getSampleBlockImpl(std::vector> const&, std::shared_ptr const&, std::shared_ptr const&, bool, bool) @ 0x000000001492cf06 5. /build/src/Interpreters/InterpreterInsertQuery.cpp:200: DB::InterpreterInsertQuery::getSampleBlock(DB::ASTInsertQuery const&, std::shared_ptr const&, std::shared_ptr const&, std::shared_ptr, bool, bool) @ 0x000000001492c400 6. /build/src/Interpreters/InterpreterInsertQuery.cpp:838: DB::InterpreterInsertQuery::execute() @ 0x0000000014933ae7 7. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88dc9 8. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 9. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 10. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 11. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 12. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 13. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 14. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 15. ? @ 0x00007fbc6213eac3 16. ? @ 0x00007fbc621d0850 2025.07.28 11:53:45.884100 [ 17208 ] {} TCPHandler: Code: 16. DB::Exception: No such column arr in table test_ixw674u7.t_rename_alter (0f1b84ac-c444-44d8-9e20-952b7b41ef44). (NO_SUCH_COLUMN_IN_TABLE), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x000000000a6a1e2b 4. /build/src/Interpreters/InterpreterInsertQuery.cpp:258: DB::InterpreterInsertQuery::getSampleBlockImpl(std::vector> const&, std::shared_ptr const&, std::shared_ptr const&, bool, bool) @ 0x000000001492cf06 5. /build/src/Interpreters/InterpreterInsertQuery.cpp:200: DB::InterpreterInsertQuery::getSampleBlock(DB::ASTInsertQuery const&, std::shared_ptr const&, std::shared_ptr const&, std::shared_ptr, bool, bool) @ 0x000000001492c400 6. /build/src/Interpreters/InterpreterInsertQuery.cpp:838: DB::InterpreterInsertQuery::execute() @ 0x0000000014933ae7 7. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88dc9 8. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 9. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 10. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 11. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 12. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 13. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 14. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 15. ? @ 0x00007fbc6213eac3 16. ? @ 0x00007fbc621d0850 2025.07.28 11:53:45.963891 [ 5327 ] {} TCPHandler: Code: 16. DB::Exception: No such column arr in table test_ixw674u7.t_rename_alter (0f1b84ac-c444-44d8-9e20-952b7b41ef44). (NO_SUCH_COLUMN_IN_TABLE), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x000000000a6a1e2b 4. /build/src/Interpreters/InterpreterInsertQuery.cpp:258: DB::InterpreterInsertQuery::getSampleBlockImpl(std::vector> const&, std::shared_ptr const&, std::shared_ptr const&, bool, bool) @ 0x000000001492cf06 5. /build/src/Interpreters/InterpreterInsertQuery.cpp:200: DB::InterpreterInsertQuery::getSampleBlock(DB::ASTInsertQuery const&, std::shared_ptr const&, std::shared_ptr const&, std::shared_ptr, bool, bool) @ 0x000000001492c400 6. /build/src/Interpreters/InterpreterInsertQuery.cpp:838: DB::InterpreterInsertQuery::execute() @ 0x0000000014933ae7 7. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88dc9 8. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 9. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 10. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 11. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 12. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 13. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 14. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 15. ? @ 0x00007fbc6213eac3 16. ? @ 0x00007fbc621d0850 2025.07.28 11:53:46.132634 [ 17255 ] {095002ea-8430-471a-b6a3-368eaa1cf70a} executeQuery: Code: 16. DB::Exception: No such column arr in table test_ixw674u7.t_rename_alter (0f1b84ac-c444-44d8-9e20-952b7b41ef44). (NO_SUCH_COLUMN_IN_TABLE) (version 25.3.6.10636.altinitytest (altinity build)) (from [::1]:46294) (comment: 03352_concurrent_rename_alter.sh) (query 1, line 1) (in query: INSERT INTO t_rename_alter (id, dt, arr) SELECT 1, now(), [(now(), 1, 'a', 'b')]), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x000000000a6a1e2b 4. /build/src/Interpreters/InterpreterInsertQuery.cpp:258: DB::InterpreterInsertQuery::getSampleBlockImpl(std::vector> const&, std::shared_ptr const&, std::shared_ptr const&, bool, bool) @ 0x000000001492cf06 5. /build/src/Interpreters/InterpreterInsertQuery.cpp:200: DB::InterpreterInsertQuery::getSampleBlock(DB::ASTInsertQuery const&, std::shared_ptr const&, std::shared_ptr const&, std::shared_ptr, bool, bool) @ 0x000000001492c400 6. /build/src/Interpreters/InterpreterInsertQuery.cpp:838: DB::InterpreterInsertQuery::execute() @ 0x0000000014933ae7 7. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88dc9 8. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 9. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 10. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 11. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 12. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 13. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 14. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 15. ? @ 0x00007fbc6213eac3 16. ? @ 0x00007fbc621d0850 2025.07.28 11:53:46.171105 [ 17255 ] {} TCPHandler: Code: 16. DB::Exception: No such column arr in table test_ixw674u7.t_rename_alter (0f1b84ac-c444-44d8-9e20-952b7b41ef44). (NO_SUCH_COLUMN_IN_TABLE), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x000000000a6a1e2b 4. /build/src/Interpreters/InterpreterInsertQuery.cpp:258: DB::InterpreterInsertQuery::getSampleBlockImpl(std::vector> const&, std::shared_ptr const&, std::shared_ptr const&, bool, bool) @ 0x000000001492cf06 5. /build/src/Interpreters/InterpreterInsertQuery.cpp:200: DB::InterpreterInsertQuery::getSampleBlock(DB::ASTInsertQuery const&, std::shared_ptr const&, std::shared_ptr const&, std::shared_ptr, bool, bool) @ 0x000000001492c400 6. /build/src/Interpreters/InterpreterInsertQuery.cpp:838: DB::InterpreterInsertQuery::execute() @ 0x0000000014933ae7 7. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88dc9 8. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 9. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 10. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 11. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 12. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 13. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 14. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 15. ? @ 0x00007fbc6213eac3 16. ? @ 0x00007fbc621d0850 2025.07.28 11:53:46.175024 [ 17251 ] {d8de59ad-6acc-4d63-af5d-e1788de405ce} executeQuery: Code: 16. DB::Exception: No such column arr in table test_ixw674u7.t_rename_alter (0f1b84ac-c444-44d8-9e20-952b7b41ef44). (NO_SUCH_COLUMN_IN_TABLE) (version 25.3.6.10636.altinitytest (altinity build)) (from [::1]:46270) (comment: 03352_concurrent_rename_alter.sh) (query 1, line 1) (in query: INSERT INTO t_rename_alter (id, dt, arr) SELECT 1, now(), [(now(), 1, 'a', 'b')]), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x000000000a6a1e2b 4. /build/src/Interpreters/InterpreterInsertQuery.cpp:258: DB::InterpreterInsertQuery::getSampleBlockImpl(std::vector> const&, std::shared_ptr const&, std::shared_ptr const&, bool, bool) @ 0x000000001492cf06 5. /build/src/Interpreters/InterpreterInsertQuery.cpp:200: DB::InterpreterInsertQuery::getSampleBlock(DB::ASTInsertQuery const&, std::shared_ptr const&, std::shared_ptr const&, std::shared_ptr, bool, bool) @ 0x000000001492c400 6. /build/src/Interpreters/InterpreterInsertQuery.cpp:838: DB::InterpreterInsertQuery::execute() @ 0x0000000014933ae7 7. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88dc9 8. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 9. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 10. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 11. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 12. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 13. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 14. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 15. ? @ 0x00007fbc6213eac3 16. ? @ 0x00007fbc621d0850 2025.07.28 11:53:46.174981 [ 17306 ] {31f1d923-e200-4140-b736-209f1de32bd0} executeQuery: Code: 16. DB::Exception: No such column arr in table test_ixw674u7.t_rename_alter (0f1b84ac-c444-44d8-9e20-952b7b41ef44). (NO_SUCH_COLUMN_IN_TABLE) (version 25.3.6.10636.altinitytest (altinity build)) (from [::1]:46274) (comment: 03352_concurrent_rename_alter.sh) (query 1, line 1) (in query: INSERT INTO t_rename_alter (id, dt, arr) SELECT 1, now(), [(now(), 1, 'a', 'b')]), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x000000000a6a1e2b 4. /build/src/Interpreters/InterpreterInsertQuery.cpp:258: DB::InterpreterInsertQuery::getSampleBlockImpl(std::vector> const&, std::shared_ptr const&, std::shared_ptr const&, bool, bool) @ 0x000000001492cf06 5. /build/src/Interpreters/InterpreterInsertQuery.cpp:200: DB::InterpreterInsertQuery::getSampleBlock(DB::ASTInsertQuery const&, std::shared_ptr const&, std::shared_ptr const&, std::shared_ptr, bool, bool) @ 0x000000001492c400 6. /build/src/Interpreters/InterpreterInsertQuery.cpp:838: DB::InterpreterInsertQuery::execute() @ 0x0000000014933ae7 7. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88dc9 8. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 9. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 10. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 11. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 12. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 13. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 14. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 15. ? @ 0x00007fbc6213eac3 16. ? @ 0x00007fbc621d0850 2025.07.28 11:53:46.191979 [ 17251 ] {} TCPHandler: Code: 16. DB::Exception: No such column arr in table test_ixw674u7.t_rename_alter (0f1b84ac-c444-44d8-9e20-952b7b41ef44). (NO_SUCH_COLUMN_IN_TABLE), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x000000000a6a1e2b 4. /build/src/Interpreters/InterpreterInsertQuery.cpp:258: DB::InterpreterInsertQuery::getSampleBlockImpl(std::vector> const&, std::shared_ptr const&, std::shared_ptr const&, bool, bool) @ 0x000000001492cf06 5. /build/src/Interpreters/InterpreterInsertQuery.cpp:200: DB::InterpreterInsertQuery::getSampleBlock(DB::ASTInsertQuery const&, std::shared_ptr const&, std::shared_ptr const&, std::shared_ptr, bool, bool) @ 0x000000001492c400 6. /build/src/Interpreters/InterpreterInsertQuery.cpp:838: DB::InterpreterInsertQuery::execute() @ 0x0000000014933ae7 7. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88dc9 8. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 9. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 10. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 11. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 12. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 13. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 14. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 15. ? @ 0x00007fbc6213eac3 16. ? @ 0x00007fbc621d0850 2025.07.28 11:53:46.214074 [ 17306 ] {} TCPHandler: Code: 16. DB::Exception: No such column arr in table test_ixw674u7.t_rename_alter (0f1b84ac-c444-44d8-9e20-952b7b41ef44). (NO_SUCH_COLUMN_IN_TABLE), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x000000000a6a1e2b 4. /build/src/Interpreters/InterpreterInsertQuery.cpp:258: DB::InterpreterInsertQuery::getSampleBlockImpl(std::vector> const&, std::shared_ptr const&, std::shared_ptr const&, bool, bool) @ 0x000000001492cf06 5. /build/src/Interpreters/InterpreterInsertQuery.cpp:200: DB::InterpreterInsertQuery::getSampleBlock(DB::ASTInsertQuery const&, std::shared_ptr const&, std::shared_ptr const&, std::shared_ptr, bool, bool) @ 0x000000001492c400 6. /build/src/Interpreters/InterpreterInsertQuery.cpp:838: DB::InterpreterInsertQuery::execute() @ 0x0000000014933ae7 7. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88dc9 8. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 9. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 10. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 11. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 12. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 13. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 14. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 15. ? @ 0x00007fbc6213eac3 16. ? @ 0x00007fbc621d0850 2025.07.28 11:53:46.288398 [ 12807 ] {6480d7b1-c9a6-48a2-99c6-2cdf40d867c0} executeQuery: Code: 16. DB::Exception: No such column arr in table test_ixw674u7.t_rename_alter (0f1b84ac-c444-44d8-9e20-952b7b41ef44). (NO_SUCH_COLUMN_IN_TABLE) (version 25.3.6.10636.altinitytest (altinity build)) (from [::1]:46328) (comment: 03352_concurrent_rename_alter.sh) (query 1, line 1) (in query: INSERT INTO t_rename_alter (id, dt, arr) SELECT 1, now(), [(now(), 1, 'a', 'b')]), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x000000000a6a1e2b 4. /build/src/Interpreters/InterpreterInsertQuery.cpp:258: DB::InterpreterInsertQuery::getSampleBlockImpl(std::vector> const&, std::shared_ptr const&, std::shared_ptr const&, bool, bool) @ 0x000000001492cf06 5. /build/src/Interpreters/InterpreterInsertQuery.cpp:200: DB::InterpreterInsertQuery::getSampleBlock(DB::ASTInsertQuery const&, std::shared_ptr const&, std::shared_ptr const&, std::shared_ptr, bool, bool) @ 0x000000001492c400 6. /build/src/Interpreters/InterpreterInsertQuery.cpp:838: DB::InterpreterInsertQuery::execute() @ 0x0000000014933ae7 7. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88dc9 8. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 9. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 10. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 11. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 12. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 13. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 14. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 15. ? @ 0x00007fbc6213eac3 16. ? @ 0x00007fbc621d0850 2025.07.28 11:53:46.288350 [ 17207 ] {fa841fab-d749-4e9d-b806-af790741012f} executeQuery: Code: 16. DB::Exception: No such column arr in table test_ixw674u7.t_rename_alter (0f1b84ac-c444-44d8-9e20-952b7b41ef44). (NO_SUCH_COLUMN_IN_TABLE) (version 25.3.6.10636.altinitytest (altinity build)) (from [::1]:46346) (comment: 03352_concurrent_rename_alter.sh) (query 1, line 1) (in query: INSERT INTO t_rename_alter (id, dt, arr) SELECT 1, now(), [(now(), 1, 'a', 'b')]), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x000000000a6a1e2b 4. /build/src/Interpreters/InterpreterInsertQuery.cpp:258: DB::InterpreterInsertQuery::getSampleBlockImpl(std::vector> const&, std::shared_ptr const&, std::shared_ptr const&, bool, bool) @ 0x000000001492cf06 5. /build/src/Interpreters/InterpreterInsertQuery.cpp:200: DB::InterpreterInsertQuery::getSampleBlock(DB::ASTInsertQuery const&, std::shared_ptr const&, std::shared_ptr const&, std::shared_ptr, bool, bool) @ 0x000000001492c400 6. /build/src/Interpreters/InterpreterInsertQuery.cpp:838: DB::InterpreterInsertQuery::execute() @ 0x0000000014933ae7 7. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88dc9 8. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 9. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 10. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 11. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 12. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 13. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 14. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 15. ? @ 0x00007fbc6213eac3 16. ? @ 0x00007fbc621d0850 2025.07.28 11:53:46.359049 [ 12807 ] {} TCPHandler: Code: 16. DB::Exception: No such column arr in table test_ixw674u7.t_rename_alter (0f1b84ac-c444-44d8-9e20-952b7b41ef44). (NO_SUCH_COLUMN_IN_TABLE), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x000000000a6a1e2b 4. /build/src/Interpreters/InterpreterInsertQuery.cpp:258: DB::InterpreterInsertQuery::getSampleBlockImpl(std::vector> const&, std::shared_ptr const&, std::shared_ptr const&, bool, bool) @ 0x000000001492cf06 5. /build/src/Interpreters/InterpreterInsertQuery.cpp:200: DB::InterpreterInsertQuery::getSampleBlock(DB::ASTInsertQuery const&, std::shared_ptr const&, std::shared_ptr const&, std::shared_ptr, bool, bool) @ 0x000000001492c400 6. /build/src/Interpreters/InterpreterInsertQuery.cpp:838: DB::InterpreterInsertQuery::execute() @ 0x0000000014933ae7 7. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88dc9 8. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 9. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 10. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 11. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 12. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 13. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 14. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 15. ? @ 0x00007fbc6213eac3 16. ? @ 0x00007fbc621d0850 2025.07.28 11:53:46.359518 [ 17207 ] {} TCPHandler: Code: 16. DB::Exception: No such column arr in table test_ixw674u7.t_rename_alter (0f1b84ac-c444-44d8-9e20-952b7b41ef44). (NO_SUCH_COLUMN_IN_TABLE), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x000000000a6a1e2b 4. /build/src/Interpreters/InterpreterInsertQuery.cpp:258: DB::InterpreterInsertQuery::getSampleBlockImpl(std::vector> const&, std::shared_ptr const&, std::shared_ptr const&, bool, bool) @ 0x000000001492cf06 5. /build/src/Interpreters/InterpreterInsertQuery.cpp:200: DB::InterpreterInsertQuery::getSampleBlock(DB::ASTInsertQuery const&, std::shared_ptr const&, std::shared_ptr const&, std::shared_ptr, bool, bool) @ 0x000000001492c400 6. /build/src/Interpreters/InterpreterInsertQuery.cpp:838: DB::InterpreterInsertQuery::execute() @ 0x0000000014933ae7 7. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88dc9 8. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 9. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 10. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 11. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 12. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 13. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 14. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 15. ? @ 0x00007fbc6213eac3 16. ? @ 0x00007fbc621d0850 2025.07.28 11:53:46.569285 [ 17243 ] {4136bd19-e540-49d0-a386-ea2cbf22998d} executeQuery: Code: 16. DB::Exception: No such column arr in table test_ixw674u7.t_rename_alter (0f1b84ac-c444-44d8-9e20-952b7b41ef44). (NO_SUCH_COLUMN_IN_TABLE) (version 25.3.6.10636.altinitytest (altinity build)) (from [::1]:46448) (comment: 03352_concurrent_rename_alter.sh) (query 1, line 1) (in query: INSERT INTO t_rename_alter (id, dt, arr) SELECT 1, now(), [(now(), 1, 'a', 'b')]), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x000000000a6a1e2b 4. /build/src/Interpreters/InterpreterInsertQuery.cpp:258: DB::InterpreterInsertQuery::getSampleBlockImpl(std::vector> const&, std::shared_ptr const&, std::shared_ptr const&, bool, bool) @ 0x000000001492cf06 5. /build/src/Interpreters/InterpreterInsertQuery.cpp:200: DB::InterpreterInsertQuery::getSampleBlock(DB::ASTInsertQuery const&, std::shared_ptr const&, std::shared_ptr const&, std::shared_ptr, bool, bool) @ 0x000000001492c400 6. /build/src/Interpreters/InterpreterInsertQuery.cpp:838: DB::InterpreterInsertQuery::execute() @ 0x0000000014933ae7 7. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88dc9 8. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 9. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 10. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 11. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 12. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 13. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 14. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 15. ? @ 0x00007fbc6213eac3 16. ? @ 0x00007fbc621d0850 2025.07.28 11:53:46.591894 [ 17243 ] {} TCPHandler: Code: 16. DB::Exception: No such column arr in table test_ixw674u7.t_rename_alter (0f1b84ac-c444-44d8-9e20-952b7b41ef44). (NO_SUCH_COLUMN_IN_TABLE), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x000000000a6a1e2b 4. /build/src/Interpreters/InterpreterInsertQuery.cpp:258: DB::InterpreterInsertQuery::getSampleBlockImpl(std::vector> const&, std::shared_ptr const&, std::shared_ptr const&, bool, bool) @ 0x000000001492cf06 5. /build/src/Interpreters/InterpreterInsertQuery.cpp:200: DB::InterpreterInsertQuery::getSampleBlock(DB::ASTInsertQuery const&, std::shared_ptr const&, std::shared_ptr const&, std::shared_ptr, bool, bool) @ 0x000000001492c400 6. /build/src/Interpreters/InterpreterInsertQuery.cpp:838: DB::InterpreterInsertQuery::execute() @ 0x0000000014933ae7 7. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88dc9 8. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 9. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 10. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 11. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 12. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 13. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 14. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 15. ? @ 0x00007fbc6213eac3 16. ? @ 0x00007fbc621d0850 2025.07.28 11:53:46.624319 [ 7630 ] {856ee686-2dec-4be8-915e-bfc7fd53473b} executeQuery: Code: 16. DB::Exception: No such column arr in table test_ixw674u7.t_rename_alter (0f1b84ac-c444-44d8-9e20-952b7b41ef44). (NO_SUCH_COLUMN_IN_TABLE) (version 25.3.6.10636.altinitytest (altinity build)) (from [::1]:46486) (comment: 03352_concurrent_rename_alter.sh) (query 1, line 1) (in query: INSERT INTO t_rename_alter (id, dt, arr) SELECT 1, now(), [(now(), 1, 'a', 'b')]), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x000000000a6a1e2b 4. /build/src/Interpreters/InterpreterInsertQuery.cpp:258: DB::InterpreterInsertQuery::getSampleBlockImpl(std::vector> const&, std::shared_ptr const&, std::shared_ptr const&, bool, bool) @ 0x000000001492cf06 5. /build/src/Interpreters/InterpreterInsertQuery.cpp:200: DB::InterpreterInsertQuery::getSampleBlock(DB::ASTInsertQuery const&, std::shared_ptr const&, std::shared_ptr const&, std::shared_ptr, bool, bool) @ 0x000000001492c400 6. /build/src/Interpreters/InterpreterInsertQuery.cpp:838: DB::InterpreterInsertQuery::execute() @ 0x0000000014933ae7 7. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88dc9 8. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 9. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 10. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 11. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 12. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 13. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 14. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 15. ? @ 0x00007fbc6213eac3 16. ? @ 0x00007fbc621d0850 2025.07.28 11:53:46.627135 [ 7630 ] {} TCPHandler: Code: 16. DB::Exception: No such column arr in table test_ixw674u7.t_rename_alter (0f1b84ac-c444-44d8-9e20-952b7b41ef44). (NO_SUCH_COLUMN_IN_TABLE), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x000000000a6a1e2b 4. /build/src/Interpreters/InterpreterInsertQuery.cpp:258: DB::InterpreterInsertQuery::getSampleBlockImpl(std::vector> const&, std::shared_ptr const&, std::shared_ptr const&, bool, bool) @ 0x000000001492cf06 5. /build/src/Interpreters/InterpreterInsertQuery.cpp:200: DB::InterpreterInsertQuery::getSampleBlock(DB::ASTInsertQuery const&, std::shared_ptr const&, std::shared_ptr const&, std::shared_ptr, bool, bool) @ 0x000000001492c400 6. /build/src/Interpreters/InterpreterInsertQuery.cpp:838: DB::InterpreterInsertQuery::execute() @ 0x0000000014933ae7 7. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88dc9 8. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 9. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 10. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 11. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 12. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 13. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 14. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 15. ? @ 0x00007fbc6213eac3 16. ? @ 0x00007fbc621d0850 2025.07.28 11:53:46.651698 [ 3970 ] {} test_13.rmt2 (7f9b740d-015c-470e-8cc6-8ba33be0dc63): auto DB::StorageReplicatedMergeTree::processQueueEntry(ReplicatedMergeTreeQueue::SelectedEntryPtr)::(anonymous class)::operator()(LogEntryPtr &) const: Code: 86. DB::HTTPException: Received error from remote server http://146b4357c08d:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Ftest%2F01165%2Ftest_13%2Frmt%2Freplicas%2F1&part=20250728_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.6.10636.altinitytest (altinity build)) '. (RECEIVED_ERROR_FROM_REMOTE_IO_SERVER), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.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 const&, int&&, String const&, unsigned long&&, String const&) @ 0x000000000feda8d9 4. /build/src/IO/HTTPCommon.cpp:104: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x000000000feda6e2 5. /build/src/IO/HTTPCommon.cpp:93: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x000000000feda537 6. /build/src/IO/ReadWriteBufferFromHTTP.cpp:277: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x000000001184a4c4 7. /build/src/IO/ReadWriteBufferFromHTTP.cpp:285: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x000000001184a615 8. /build/src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x000000001184ae59 9. /build/src/IO/ReadWriteBufferFromHTTP.cpp:472: void std::__function::__policy_invoker::__call_impl[abi:se190107]>(std::__function::__policy_storage const*) @ 0x000000001184cedd 10. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001184858b 11. /build/src/IO/ReadWriteBufferFromHTTP.cpp:465: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x000000001184bf0b 12. /build/src/IO/ReadBuffer.h:60: DB::ReadBuffer::next() @ 0x000000000a148c7b 13. /build/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) @ 0x0000000011849fb2 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]>&)>&, 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&) @ 0x0000000011841980 15. /build/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) @ 0x000000001621208e 16. /build/src/Storages/StorageReplicatedMergeTree.cpp:5228: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl[abi:se190107] const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000015f9a5fe 17. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000015ed8bfd 18. /build/src/Storages/StorageReplicatedMergeTree.cpp:2514: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x0000000015ec9aab 19. /build/src/Storages/StorageReplicatedMergeTree.cpp:2349: DB::StorageReplicatedMergeTree::executeLogEntry(DB::ReplicatedMergeTreeLogEntry&) @ 0x0000000015eba91b 20. /build/src/Storages/StorageReplicatedMergeTree.cpp:3876: bool std::__function::__policy_invoker&)>::__call_impl[abi:se190107])::$_1, bool (std::shared_ptr&)>>(std::__function::__policy_storage const*, std::shared_ptr&) @ 0x0000000015f9837e 21. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000165d6fc3 22. /build/src/Storages/StorageReplicatedMergeTree.cpp:3872: DB::StorageReplicatedMergeTree::processQueueEntry(std::shared_ptr) @ 0x0000000015efc18a 23. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001624c1b2 24. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000162f9c70 25. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x00000000162fa55a 26. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc6653 27. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000000fccc4c3 28. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc3d92 29. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fcca080 30. ? @ 0x00007fbc6213eac3 31. ? @ 0x00007fbc621d0850 (version 25.3.6.10636.altinitytest (altinity build)) 2025.07.28 11:53:46.672534 [ 4581 ] {d90b4a52-20ec-4abe-ae93-525333f482b9} executeQuery: Code: 16. DB::Exception: No such column arr in table test_ixw674u7.t_rename_alter (0f1b84ac-c444-44d8-9e20-952b7b41ef44). (NO_SUCH_COLUMN_IN_TABLE) (version 25.3.6.10636.altinitytest (altinity build)) (from [::1]:46488) (comment: 03352_concurrent_rename_alter.sh) (query 1, line 1) (in query: INSERT INTO t_rename_alter (id, dt, arr) SELECT 1, now(), [(now(), 1, 'a', 'b')]), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x000000000a6a1e2b 4. /build/src/Interpreters/InterpreterInsertQuery.cpp:258: DB::InterpreterInsertQuery::getSampleBlockImpl(std::vector> const&, std::shared_ptr const&, std::shared_ptr const&, bool, bool) @ 0x000000001492cf06 5. /build/src/Interpreters/InterpreterInsertQuery.cpp:200: DB::InterpreterInsertQuery::getSampleBlock(DB::ASTInsertQuery const&, std::shared_ptr const&, std::shared_ptr const&, std::shared_ptr, bool, bool) @ 0x000000001492c400 6. /build/src/Interpreters/InterpreterInsertQuery.cpp:838: DB::InterpreterInsertQuery::execute() @ 0x0000000014933ae7 7. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88dc9 8. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 9. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 10. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 11. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 12. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 13. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 14. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 15. ? @ 0x00007fbc6213eac3 16. ? @ 0x00007fbc621d0850 2025.07.28 11:53:46.698258 [ 4581 ] {} TCPHandler: Code: 16. DB::Exception: No such column arr in table test_ixw674u7.t_rename_alter (0f1b84ac-c444-44d8-9e20-952b7b41ef44). (NO_SUCH_COLUMN_IN_TABLE), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x000000000a6a1e2b 4. /build/src/Interpreters/InterpreterInsertQuery.cpp:258: DB::InterpreterInsertQuery::getSampleBlockImpl(std::vector> const&, std::shared_ptr const&, std::shared_ptr const&, bool, bool) @ 0x000000001492cf06 5. /build/src/Interpreters/InterpreterInsertQuery.cpp:200: DB::InterpreterInsertQuery::getSampleBlock(DB::ASTInsertQuery const&, std::shared_ptr const&, std::shared_ptr const&, std::shared_ptr, bool, bool) @ 0x000000001492c400 6. /build/src/Interpreters/InterpreterInsertQuery.cpp:838: DB::InterpreterInsertQuery::execute() @ 0x0000000014933ae7 7. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88dc9 8. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 9. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 10. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 11. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 12. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 13. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 14. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 15. ? @ 0x00007fbc6213eac3 16. ? @ 0x00007fbc621d0850 2025.07.28 11:53:46.699925 [ 17207 ] {cc2bb209-3586-4b25-844a-ccf39b27a72c} executeQuery: Code: 16. DB::Exception: No such column arr in table test_ixw674u7.t_rename_alter (0f1b84ac-c444-44d8-9e20-952b7b41ef44). (NO_SUCH_COLUMN_IN_TABLE) (version 25.3.6.10636.altinitytest (altinity build)) (from [::1]:46470) (comment: 03352_concurrent_rename_alter.sh) (query 1, line 1) (in query: INSERT INTO t_rename_alter (id, dt, arr) SELECT 1, now(), [(now(), 1, 'a', 'b')]), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x000000000a6a1e2b 4. /build/src/Interpreters/InterpreterInsertQuery.cpp:258: DB::InterpreterInsertQuery::getSampleBlockImpl(std::vector> const&, std::shared_ptr const&, std::shared_ptr const&, bool, bool) @ 0x000000001492cf06 5. /build/src/Interpreters/InterpreterInsertQuery.cpp:200: DB::InterpreterInsertQuery::getSampleBlock(DB::ASTInsertQuery const&, std::shared_ptr const&, std::shared_ptr const&, std::shared_ptr, bool, bool) @ 0x000000001492c400 6. /build/src/Interpreters/InterpreterInsertQuery.cpp:838: DB::InterpreterInsertQuery::execute() @ 0x0000000014933ae7 7. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88dc9 8. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 9. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 10. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 11. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 12. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 13. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 14. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 15. ? @ 0x00007fbc6213eac3 16. ? @ 0x00007fbc621d0850 2025.07.28 11:53:46.724306 [ 17207 ] {} TCPHandler: Code: 16. DB::Exception: No such column arr in table test_ixw674u7.t_rename_alter (0f1b84ac-c444-44d8-9e20-952b7b41ef44). (NO_SUCH_COLUMN_IN_TABLE), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x000000000a6a1e2b 4. /build/src/Interpreters/InterpreterInsertQuery.cpp:258: DB::InterpreterInsertQuery::getSampleBlockImpl(std::vector> const&, std::shared_ptr const&, std::shared_ptr const&, bool, bool) @ 0x000000001492cf06 5. /build/src/Interpreters/InterpreterInsertQuery.cpp:200: DB::InterpreterInsertQuery::getSampleBlock(DB::ASTInsertQuery const&, std::shared_ptr const&, std::shared_ptr const&, std::shared_ptr, bool, bool) @ 0x000000001492c400 6. /build/src/Interpreters/InterpreterInsertQuery.cpp:838: DB::InterpreterInsertQuery::execute() @ 0x0000000014933ae7 7. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88dc9 8. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 9. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 10. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 11. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 12. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 13. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 14. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 15. ? @ 0x00007fbc6213eac3 16. ? @ 0x00007fbc621d0850 2025.07.28 11:53:46.747964 [ 5825 ] {2f7826cd-c847-4c50-807d-5aea52331818} executeQuery: Code: 16. DB::Exception: No such column arr in table test_ixw674u7.t_rename_alter (0f1b84ac-c444-44d8-9e20-952b7b41ef44). (NO_SUCH_COLUMN_IN_TABLE) (version 25.3.6.10636.altinitytest (altinity build)) (from [::1]:46502) (comment: 03352_concurrent_rename_alter.sh) (query 1, line 1) (in query: INSERT INTO t_rename_alter (id, dt, arr) SELECT 1, now(), [(now(), 1, 'a', 'b')]), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x000000000a6a1e2b 4. /build/src/Interpreters/InterpreterInsertQuery.cpp:258: DB::InterpreterInsertQuery::getSampleBlockImpl(std::vector> const&, std::shared_ptr const&, std::shared_ptr const&, bool, bool) @ 0x000000001492cf06 5. /build/src/Interpreters/InterpreterInsertQuery.cpp:200: DB::InterpreterInsertQuery::getSampleBlock(DB::ASTInsertQuery const&, std::shared_ptr const&, std::shared_ptr const&, std::shared_ptr, bool, bool) @ 0x000000001492c400 6. /build/src/Interpreters/InterpreterInsertQuery.cpp:838: DB::InterpreterInsertQuery::execute() @ 0x0000000014933ae7 7. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88dc9 8. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 9. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 10. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 11. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 12. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 13. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 14. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 15. ? @ 0x00007fbc6213eac3 16. ? @ 0x00007fbc621d0850 2025.07.28 11:53:46.797495 [ 5825 ] {} TCPHandler: Code: 16. DB::Exception: No such column arr in table test_ixw674u7.t_rename_alter (0f1b84ac-c444-44d8-9e20-952b7b41ef44). (NO_SUCH_COLUMN_IN_TABLE), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x000000000a6a1e2b 4. /build/src/Interpreters/InterpreterInsertQuery.cpp:258: DB::InterpreterInsertQuery::getSampleBlockImpl(std::vector> const&, std::shared_ptr const&, std::shared_ptr const&, bool, bool) @ 0x000000001492cf06 5. /build/src/Interpreters/InterpreterInsertQuery.cpp:200: DB::InterpreterInsertQuery::getSampleBlock(DB::ASTInsertQuery const&, std::shared_ptr const&, std::shared_ptr const&, std::shared_ptr, bool, bool) @ 0x000000001492c400 6. /build/src/Interpreters/InterpreterInsertQuery.cpp:838: DB::InterpreterInsertQuery::execute() @ 0x0000000014933ae7 7. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88dc9 8. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 9. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 10. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 11. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 12. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 13. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 14. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 15. ? @ 0x00007fbc6213eac3 16. ? @ 0x00007fbc621d0850 2025.07.28 11:53:46.915370 [ 12807 ] {7b72d700-d96f-4b1e-9a7e-5d54352e80df} executeQuery: Code: 16. DB::Exception: No such column arr in table test_ixw674u7.t_rename_alter (0f1b84ac-c444-44d8-9e20-952b7b41ef44). (NO_SUCH_COLUMN_IN_TABLE) (version 25.3.6.10636.altinitytest (altinity build)) (from [::1]:46508) (comment: 03352_concurrent_rename_alter.sh) (query 1, line 1) (in query: INSERT INTO t_rename_alter (id, dt, arr) SELECT 1, now(), [(now(), 1, 'a', 'b')]), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x000000000a6a1e2b 4. /build/src/Interpreters/InterpreterInsertQuery.cpp:258: DB::InterpreterInsertQuery::getSampleBlockImpl(std::vector> const&, std::shared_ptr const&, std::shared_ptr const&, bool, bool) @ 0x000000001492cf06 5. /build/src/Interpreters/InterpreterInsertQuery.cpp:200: DB::InterpreterInsertQuery::getSampleBlock(DB::ASTInsertQuery const&, std::shared_ptr const&, std::shared_ptr const&, std::shared_ptr, bool, bool) @ 0x000000001492c400 6. /build/src/Interpreters/InterpreterInsertQuery.cpp:838: DB::InterpreterInsertQuery::execute() @ 0x0000000014933ae7 7. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88dc9 8. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 9. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 10. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 11. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 12. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 13. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 14. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 15. ? @ 0x00007fbc6213eac3 16. ? @ 0x00007fbc621d0850 2025.07.28 11:53:46.956931 [ 12807 ] {} TCPHandler: Code: 16. DB::Exception: No such column arr in table test_ixw674u7.t_rename_alter (0f1b84ac-c444-44d8-9e20-952b7b41ef44). (NO_SUCH_COLUMN_IN_TABLE), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x000000000a6a1e2b 4. /build/src/Interpreters/InterpreterInsertQuery.cpp:258: DB::InterpreterInsertQuery::getSampleBlockImpl(std::vector> const&, std::shared_ptr const&, std::shared_ptr const&, bool, bool) @ 0x000000001492cf06 5. /build/src/Interpreters/InterpreterInsertQuery.cpp:200: DB::InterpreterInsertQuery::getSampleBlock(DB::ASTInsertQuery const&, std::shared_ptr const&, std::shared_ptr const&, std::shared_ptr, bool, bool) @ 0x000000001492c400 6. /build/src/Interpreters/InterpreterInsertQuery.cpp:838: DB::InterpreterInsertQuery::execute() @ 0x0000000014933ae7 7. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88dc9 8. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 9. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 10. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 11. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 12. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 13. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 14. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 15. ? @ 0x00007fbc6213eac3 16. ? @ 0x00007fbc621d0850 2025.07.28 11:53:47.011135 [ 17321 ] {5f77b41c-8d4b-4a00-83b7-9568747846fa} executeQuery: Code: 16. DB::Exception: No such column arr in table test_ixw674u7.t_rename_alter (0f1b84ac-c444-44d8-9e20-952b7b41ef44). (NO_SUCH_COLUMN_IN_TABLE) (version 25.3.6.10636.altinitytest (altinity build)) (from [::1]:46562) (comment: 03352_concurrent_rename_alter.sh) (query 1, line 1) (in query: INSERT INTO t_rename_alter (id, dt, arr) SELECT 1, now(), [(now(), 1, 'a', 'b')]), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x000000000a6a1e2b 4. /build/src/Interpreters/InterpreterInsertQuery.cpp:258: DB::InterpreterInsertQuery::getSampleBlockImpl(std::vector> const&, std::shared_ptr const&, std::shared_ptr const&, bool, bool) @ 0x000000001492cf06 5. /build/src/Interpreters/InterpreterInsertQuery.cpp:200: DB::InterpreterInsertQuery::getSampleBlock(DB::ASTInsertQuery const&, std::shared_ptr const&, std::shared_ptr const&, std::shared_ptr, bool, bool) @ 0x000000001492c400 6. /build/src/Interpreters/InterpreterInsertQuery.cpp:838: DB::InterpreterInsertQuery::execute() @ 0x0000000014933ae7 7. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88dc9 8. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 9. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 10. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 11. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 12. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 13. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 14. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 15. ? @ 0x00007fbc6213eac3 16. ? @ 0x00007fbc621d0850 2025.07.28 11:53:47.020873 [ 17321 ] {} TCPHandler: Code: 16. DB::Exception: No such column arr in table test_ixw674u7.t_rename_alter (0f1b84ac-c444-44d8-9e20-952b7b41ef44). (NO_SUCH_COLUMN_IN_TABLE), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x000000000a6a1e2b 4. /build/src/Interpreters/InterpreterInsertQuery.cpp:258: DB::InterpreterInsertQuery::getSampleBlockImpl(std::vector> const&, std::shared_ptr const&, std::shared_ptr const&, bool, bool) @ 0x000000001492cf06 5. /build/src/Interpreters/InterpreterInsertQuery.cpp:200: DB::InterpreterInsertQuery::getSampleBlock(DB::ASTInsertQuery const&, std::shared_ptr const&, std::shared_ptr const&, std::shared_ptr, bool, bool) @ 0x000000001492c400 6. /build/src/Interpreters/InterpreterInsertQuery.cpp:838: DB::InterpreterInsertQuery::execute() @ 0x0000000014933ae7 7. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88dc9 8. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 9. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 10. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 11. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 12. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 13. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 14. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 15. ? @ 0x00007fbc6213eac3 16. ? @ 0x00007fbc621d0850 2025.07.28 11:53:47.059926 [ 5825 ] {f654538c-80fa-4fbc-8b3e-ce68e100ee6c} executeQuery: Code: 16. DB::Exception: No such column arr in table test_ixw674u7.t_rename_alter (0f1b84ac-c444-44d8-9e20-952b7b41ef44). (NO_SUCH_COLUMN_IN_TABLE) (version 25.3.6.10636.altinitytest (altinity build)) (from [::1]:46564) (comment: 03352_concurrent_rename_alter.sh) (query 1, line 1) (in query: INSERT INTO t_rename_alter (id, dt, arr) SELECT 1, now(), [(now(), 1, 'a', 'b')]), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x000000000a6a1e2b 4. /build/src/Interpreters/InterpreterInsertQuery.cpp:258: DB::InterpreterInsertQuery::getSampleBlockImpl(std::vector> const&, std::shared_ptr const&, std::shared_ptr const&, bool, bool) @ 0x000000001492cf06 5. /build/src/Interpreters/InterpreterInsertQuery.cpp:200: DB::InterpreterInsertQuery::getSampleBlock(DB::ASTInsertQuery const&, std::shared_ptr const&, std::shared_ptr const&, std::shared_ptr, bool, bool) @ 0x000000001492c400 6. /build/src/Interpreters/InterpreterInsertQuery.cpp:838: DB::InterpreterInsertQuery::execute() @ 0x0000000014933ae7 7. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88dc9 8. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 9. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 10. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 11. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 12. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 13. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 14. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 15. ? @ 0x00007fbc6213eac3 16. ? @ 0x00007fbc621d0850 2025.07.28 11:53:47.060835 [ 5747 ] {5a755fd5-e415-4ddf-9dd8-eb157cb2ff0a} executeQuery: Code: 16. DB::Exception: No such column arr in table test_ixw674u7.t_rename_alter (0f1b84ac-c444-44d8-9e20-952b7b41ef44). (NO_SUCH_COLUMN_IN_TABLE) (version 25.3.6.10636.altinitytest (altinity build)) (from [::1]:46536) (comment: 03352_concurrent_rename_alter.sh) (query 1, line 1) (in query: INSERT INTO t_rename_alter (id, dt, arr) SELECT 1, now(), [(now(), 1, 'a', 'b')]), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x000000000a6a1e2b 4. /build/src/Interpreters/InterpreterInsertQuery.cpp:258: DB::InterpreterInsertQuery::getSampleBlockImpl(std::vector> const&, std::shared_ptr const&, std::shared_ptr const&, bool, bool) @ 0x000000001492cf06 5. /build/src/Interpreters/InterpreterInsertQuery.cpp:200: DB::InterpreterInsertQuery::getSampleBlock(DB::ASTInsertQuery const&, std::shared_ptr const&, std::shared_ptr const&, std::shared_ptr, bool, bool) @ 0x000000001492c400 6. /build/src/Interpreters/InterpreterInsertQuery.cpp:838: DB::InterpreterInsertQuery::execute() @ 0x0000000014933ae7 7. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88dc9 8. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 9. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 10. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 11. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 12. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 13. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 14. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 15. ? @ 0x00007fbc6213eac3 16. ? @ 0x00007fbc621d0850 2025.07.28 11:53:47.077416 [ 3968 ] {} test_13.rmt2 (7f9b740d-015c-470e-8cc6-8ba33be0dc63): auto DB::StorageReplicatedMergeTree::processQueueEntry(ReplicatedMergeTreeQueue::SelectedEntryPtr)::(anonymous class)::operator()(LogEntryPtr &) const: Code: 86. DB::HTTPException: Received error from remote server http://146b4357c08d:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Ftest%2F01165%2Ftest_13%2Frmt%2Freplicas%2F1&part=20250728_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.6.10636.altinitytest (altinity build)) '. (RECEIVED_ERROR_FROM_REMOTE_IO_SERVER), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.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 const&, int&&, String const&, unsigned long&&, String const&) @ 0x000000000feda8d9 4. /build/src/IO/HTTPCommon.cpp:104: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x000000000feda6e2 5. /build/src/IO/HTTPCommon.cpp:93: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x000000000feda537 6. /build/src/IO/ReadWriteBufferFromHTTP.cpp:277: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x000000001184a4c4 7. /build/src/IO/ReadWriteBufferFromHTTP.cpp:285: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x000000001184a615 8. /build/src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x000000001184ae59 9. /build/src/IO/ReadWriteBufferFromHTTP.cpp:472: void std::__function::__policy_invoker::__call_impl[abi:se190107]>(std::__function::__policy_storage const*) @ 0x000000001184cedd 10. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001184858b 11. /build/src/IO/ReadWriteBufferFromHTTP.cpp:465: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x000000001184bf0b 12. /build/src/IO/ReadBuffer.h:60: DB::ReadBuffer::next() @ 0x000000000a148c7b 13. /build/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) @ 0x0000000011849fb2 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]>&)>&, 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&) @ 0x0000000011841980 15. /build/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) @ 0x000000001621208e 16. /build/src/Storages/StorageReplicatedMergeTree.cpp:5228: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl[abi:se190107] const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000015f9a5fe 17. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000015ed8bfd 18. /build/src/Storages/StorageReplicatedMergeTree.cpp:2514: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x0000000015ec9aab 19. /build/src/Storages/StorageReplicatedMergeTree.cpp:2349: DB::StorageReplicatedMergeTree::executeLogEntry(DB::ReplicatedMergeTreeLogEntry&) @ 0x0000000015eba91b 20. /build/src/Storages/StorageReplicatedMergeTree.cpp:3876: bool std::__function::__policy_invoker&)>::__call_impl[abi:se190107])::$_1, bool (std::shared_ptr&)>>(std::__function::__policy_storage const*, std::shared_ptr&) @ 0x0000000015f9837e 21. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000165d6fc3 22. /build/src/Storages/StorageReplicatedMergeTree.cpp:3872: DB::StorageReplicatedMergeTree::processQueueEntry(std::shared_ptr) @ 0x0000000015efc18a 23. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001624c1b2 24. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000162f9c70 25. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x00000000162fa55a 26. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc6653 27. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000000fccc4c3 28. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc3d92 29. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fcca080 30. ? @ 0x00007fbc6213eac3 31. ? @ 0x00007fbc621d0850 (version 25.3.6.10636.altinitytest (altinity build)) 2025.07.28 11:53:47.086476 [ 5825 ] {} TCPHandler: Code: 16. DB::Exception: No such column arr in table test_ixw674u7.t_rename_alter (0f1b84ac-c444-44d8-9e20-952b7b41ef44). (NO_SUCH_COLUMN_IN_TABLE), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x000000000a6a1e2b 4. /build/src/Interpreters/InterpreterInsertQuery.cpp:258: DB::InterpreterInsertQuery::getSampleBlockImpl(std::vector> const&, std::shared_ptr const&, std::shared_ptr const&, bool, bool) @ 0x000000001492cf06 5. /build/src/Interpreters/InterpreterInsertQuery.cpp:200: DB::InterpreterInsertQuery::getSampleBlock(DB::ASTInsertQuery const&, std::shared_ptr const&, std::shared_ptr const&, std::shared_ptr, bool, bool) @ 0x000000001492c400 6. /build/src/Interpreters/InterpreterInsertQuery.cpp:838: DB::InterpreterInsertQuery::execute() @ 0x0000000014933ae7 7. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88dc9 8. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 9. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 10. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 11. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 12. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 13. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 14. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 15. ? @ 0x00007fbc6213eac3 16. ? @ 0x00007fbc621d0850 2025.07.28 11:53:47.120622 [ 5825 ] {} TCPHandler: TCPHandler: Code: 210. DB::NetException: Connection reset by peer, while reading from socket (peer: [::1]:46564, local: [::1]:9000). (NETWORK_ERROR), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::NetException::NetException(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&) @ 0x000000000fd50fb5 3. /build/src/IO/ReadBufferFromPocoSocket.cpp:83: DB::ReadBufferFromPocoSocketBase::socketReceiveBytesImpl(char*, unsigned long) @ 0x000000000fd5052e 4. /build/src/IO/ReadBufferFromPocoSocket.cpp:107: DB::ReadBufferFromPocoSocketBase::nextImpl() @ 0x000000000fd50a63 5. /build/src/IO/ReadBuffer.h:60: DB::ReadBuffer::next() @ 0x000000000a148c7b 6. /build/src/IO/ReadBuffer.h:96: DB::TCPHandler::runImpl() @ 0x00000000168e5e5e 7. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 8. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 9. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 10. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 11. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 12. ? @ 0x00007fbc6213eac3 13. ? @ 0x00007fbc621d0850 (version 25.3.6.10636.altinitytest (altinity build)) 2025.07.28 11:53:47.121901 [ 5825 ] {} ServerErrorHandler: Code: 210. DB::NetException: Connection reset by peer, while reading from socket (peer: [::1]:46564, local: [::1]:9000). (NETWORK_ERROR), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::NetException::NetException(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&) @ 0x000000000fd50fb5 3. /build/src/IO/ReadBufferFromPocoSocket.cpp:83: DB::ReadBufferFromPocoSocketBase::socketReceiveBytesImpl(char*, unsigned long) @ 0x000000000fd5052e 4. /build/src/IO/ReadBufferFromPocoSocket.cpp:107: DB::ReadBufferFromPocoSocketBase::nextImpl() @ 0x000000000fd50a63 5. /build/src/IO/ReadBuffer.h:60: DB::ReadBuffer::next() @ 0x000000000a148c7b 6. /build/src/IO/ReadBuffer.h:96: DB::TCPHandler::runImpl() @ 0x00000000168e5e5e 7. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 8. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 9. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 10. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 11. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 12. ? @ 0x00007fbc6213eac3 13. ? @ 0x00007fbc621d0850 (version 25.3.6.10636.altinitytest (altinity build)) 2025.07.28 11:53:47.122142 [ 5747 ] {} TCPHandler: Code: 16. DB::Exception: No such column arr in table test_ixw674u7.t_rename_alter (0f1b84ac-c444-44d8-9e20-952b7b41ef44). (NO_SUCH_COLUMN_IN_TABLE), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x000000000a6a1e2b 4. /build/src/Interpreters/InterpreterInsertQuery.cpp:258: DB::InterpreterInsertQuery::getSampleBlockImpl(std::vector> const&, std::shared_ptr const&, std::shared_ptr const&, bool, bool) @ 0x000000001492cf06 5. /build/src/Interpreters/InterpreterInsertQuery.cpp:200: DB::InterpreterInsertQuery::getSampleBlock(DB::ASTInsertQuery const&, std::shared_ptr const&, std::shared_ptr const&, std::shared_ptr, bool, bool) @ 0x000000001492c400 6. /build/src/Interpreters/InterpreterInsertQuery.cpp:838: DB::InterpreterInsertQuery::execute() @ 0x0000000014933ae7 7. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88dc9 8. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 9. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 10. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 11. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 12. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 13. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 14. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 15. ? @ 0x00007fbc6213eac3 16. ? @ 0x00007fbc621d0850 2025.07.28 11:53:47.149759 [ 3287 ] {a9924557-d994-475b-873f-980ccb17df34} executeQuery: Code: 16. DB::Exception: No such column arr in table test_ixw674u7.t_rename_alter (0f1b84ac-c444-44d8-9e20-952b7b41ef44). (NO_SUCH_COLUMN_IN_TABLE) (version 25.3.6.10636.altinitytest (altinity build)) (from [::1]:46596) (comment: 03352_concurrent_rename_alter.sh) (query 1, line 1) (in query: INSERT INTO t_rename_alter (id, dt, arr) SELECT 1, now(), [(now(), 1, 'a', 'b')]), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x000000000a6a1e2b 4. /build/src/Interpreters/InterpreterInsertQuery.cpp:258: DB::InterpreterInsertQuery::getSampleBlockImpl(std::vector> const&, std::shared_ptr const&, std::shared_ptr const&, bool, bool) @ 0x000000001492cf06 5. /build/src/Interpreters/InterpreterInsertQuery.cpp:200: DB::InterpreterInsertQuery::getSampleBlock(DB::ASTInsertQuery const&, std::shared_ptr const&, std::shared_ptr const&, std::shared_ptr, bool, bool) @ 0x000000001492c400 6. /build/src/Interpreters/InterpreterInsertQuery.cpp:838: DB::InterpreterInsertQuery::execute() @ 0x0000000014933ae7 7. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88dc9 8. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 9. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 10. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 11. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 12. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 13. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 14. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 15. ? @ 0x00007fbc6213eac3 16. ? @ 0x00007fbc621d0850 2025.07.28 11:53:47.172762 [ 17371 ] {ee8d06eb-bc17-443c-89a9-aede2f2fb9e2} executeQuery: Code: 210. DB::NetException: I/O error: Broken pipe, while writing to socket ([::1]:9000 -> [::1]:46600). (NETWORK_ERROR) (version 25.3.6.10636.altinitytest (altinity build)) (from [::1]:46600) (comment: 03352_concurrent_rename_alter.sh) (query 1, line 1) (in query: SELECT count() FROM t_rename_alter WHERE NOT ignore(*) FORMAT Null;), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::NetException::NetException(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&) @ 0x000000000fd50fb5 3. /build/src/IO/WriteBufferFromPocoSocket.cpp:171: DB::WriteBufferFromPocoSocket::nextImpl() @ 0x000000000fd525a7 4. /build/src/IO/WriteBuffer.h:53: DB::WriteBuffer::next() @ 0x000000000a0755be 5. /build/src/Server/TCPHandler.cpp:2590: DB::TCPHandler::sendProgress(DB::QueryState&) @ 0x00000000168f1bfc 6. /build/src/Server/TCPHandler.cpp:1293: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x00000000168f1827 7. /build/src/Server/TCPHandler.cpp:678: DB::TCPHandler::runImpl() @ 0x00000000168e68e5 8. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 9. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 10. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 11. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 12. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 13. ? @ 0x00007fbc6213eac3 14. ? @ 0x00007fbc621d0850 2025.07.28 11:53:47.170012 [ 5879 ] {fa863c4a-8132-4911-a303-dae14c680a01} executeQuery: Code: 210. DB::NetException: I/O error: Broken pipe, while writing to socket ([::1]:9000 -> [::1]:46370). (NETWORK_ERROR) (version 25.3.6.10636.altinitytest (altinity build)) (from [::1]:46370) (comment: 03352_concurrent_rename_alter.sh) (query 1, line 1) (in query: INSERT INTO t_rename_alter (id, dt, arr_v2) SELECT 1, now(), [(now(), 1, 'a', 'b', 'c')]), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::NetException::NetException(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&) @ 0x000000000fd50fb5 3. /build/src/IO/WriteBufferFromPocoSocket.cpp:171: DB::WriteBufferFromPocoSocket::nextImpl() @ 0x000000000fd525a7 4. /build/src/IO/WriteBuffer.h:53: DB::WriteBuffer::next() @ 0x000000000a0755be 5. /build/src/Server/TCPHandler.cpp:1476: DB::TCPHandler::sendProfileEvents(DB::QueryState&) @ 0x00000000168fc4e6 6. /build/src/Server/TCPHandler.cpp:1491: DB::TCPHandler::runImpl() @ 0x00000000168e6b9a 7. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 8. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 9. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 10. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 11. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 12. ? @ 0x00007fbc6213eac3 13. ? @ 0x00007fbc621d0850 2025.07.28 11:53:47.182987 [ 17371 ] {} TCPHandler: Code: 210. DB::NetException: I/O error: Broken pipe, while writing to socket ([::1]:9000 -> [::1]:46600). (NETWORK_ERROR), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::NetException::NetException(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&) @ 0x000000000fd50fb5 3. /build/src/IO/WriteBufferFromPocoSocket.cpp:171: DB::WriteBufferFromPocoSocket::nextImpl() @ 0x000000000fd525a7 4. /build/src/IO/WriteBuffer.h:53: DB::WriteBuffer::next() @ 0x000000000a0755be 5. /build/src/Server/TCPHandler.cpp:2590: DB::TCPHandler::sendProgress(DB::QueryState&) @ 0x00000000168f1bfc 6. /build/src/Server/TCPHandler.cpp:1293: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x00000000168f1827 7. /build/src/Server/TCPHandler.cpp:678: DB::TCPHandler::runImpl() @ 0x00000000168e68e5 8. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 9. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 10. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 11. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 12. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 13. ? @ 0x00007fbc6213eac3 14. ? @ 0x00007fbc621d0850 2025.07.28 11:53:47.186409 [ 3287 ] {a9924557-d994-475b-873f-980ccb17df34} 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]:46596). (NETWORK_ERROR), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::NetException::NetException(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&) @ 0x000000000fd50fb5 3. /build/src/IO/WriteBufferFromPocoSocket.cpp:171: DB::WriteBufferFromPocoSocket::nextImpl() @ 0x000000000fd525a7 4. /build/src/IO/WriteBuffer.h:53: DB::WriteBuffer::next() @ 0x000000000a0755be 5. /build/src/Server/TCPHandler.cpp:826: DB::TCPHandler::runImpl() @ 0x00000000168e6c9c 6. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 7. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 8. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 9. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 10. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 11. ? @ 0x00007fbc6213eac3 12. ? @ 0x00007fbc621d0850 (version 25.3.6.10636.altinitytest (altinity build)) 2025.07.28 11:53:47.228852 [ 3287 ] {} TCPHandler: Code: 16. DB::Exception: No such column arr in table test_ixw674u7.t_rename_alter (0f1b84ac-c444-44d8-9e20-952b7b41ef44). (NO_SUCH_COLUMN_IN_TABLE), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x000000000a6a1e2b 4. /build/src/Interpreters/InterpreterInsertQuery.cpp:258: DB::InterpreterInsertQuery::getSampleBlockImpl(std::vector> const&, std::shared_ptr const&, std::shared_ptr const&, bool, bool) @ 0x000000001492cf06 5. /build/src/Interpreters/InterpreterInsertQuery.cpp:200: DB::InterpreterInsertQuery::getSampleBlock(DB::ASTInsertQuery const&, std::shared_ptr const&, std::shared_ptr const&, std::shared_ptr, bool, bool) @ 0x000000001492c400 6. /build/src/Interpreters/InterpreterInsertQuery.cpp:838: DB::InterpreterInsertQuery::execute() @ 0x0000000014933ae7 7. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88dc9 8. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 9. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 10. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 11. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 12. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 13. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 14. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 15. ? @ 0x00007fbc6213eac3 16. ? @ 0x00007fbc621d0850 2025.07.28 11:53:47.245758 [ 5879 ] {} TCPHandler: Code: 210. DB::NetException: I/O error: Broken pipe, while writing to socket ([::1]:9000 -> [::1]:46370). (NETWORK_ERROR), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::NetException::NetException(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&) @ 0x000000000fd50fb5 3. /build/src/IO/WriteBufferFromPocoSocket.cpp:171: DB::WriteBufferFromPocoSocket::nextImpl() @ 0x000000000fd525a7 4. /build/src/IO/WriteBuffer.h:53: DB::WriteBuffer::next() @ 0x000000000a0755be 5. /build/src/Server/TCPHandler.cpp:1476: DB::TCPHandler::sendProfileEvents(DB::QueryState&) @ 0x00000000168fc4e6 6. /build/src/Server/TCPHandler.cpp:1491: DB::TCPHandler::runImpl() @ 0x00000000168e6b9a 7. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 8. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 9. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 10. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 11. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 12. ? @ 0x00007fbc6213eac3 13. ? @ 0x00007fbc621d0850 2025.07.28 11:53:47.304992 [ 17256 ] {64905aa4-294b-43ca-861f-01aaf4a55d93} executeQuery: Code: 153. DB::Exception: Division by zero: while executing 'FUNCTION modulo(1_UInt8 :: 1, modulo(plus(__table1.number, 500_UInt16), 1000_UInt16) :: 2) -> modulo(1_UInt8, modulo(plus(__table1.number, 500_UInt16), 1000_UInt16)) UInt16 : 3'. (ILLEGAL_DIVISION) (version 25.3.6.10636.altinitytest (altinity build)) (from [::1]:40416) (comment: 00093_union_race_conditions_4.sh) (query 1, line 1) (in query: SELECT 1 % ((number + 500) % 1000) FROM numbers_mt(1000);), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000000a074fcb 4. /build/src/Functions/DivisionUtils.h:26: void DB::impl_::BinaryOperation, unsigned short>::process<(DB::impl_::OpCase)1>(char8_t const*, unsigned short const*, unsigned short*, unsigned long, DB::PODArray, 63ul, 64ul> const*) @ 0x000000000d184621 5. /build/src/Functions/FunctionBinaryArithmetic.h:2338: COW::immutable_ptr DB::FunctionBinaryArithmetic::executeNumeric, DB::DataTypeNumber>(std::vector> const&, DB::DataTypeNumber const&, DB::DataTypeNumber const&, DB::PODArray, 63ul, 64ul> const*) const @ 0x000000000d3a6416 6. /build/src/Functions/FunctionBinaryArithmetic.h:2508: 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&&) @ 0x000000000d3a4a68 7. /build/src/Functions/FunctionBinaryArithmetic.h:846: 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&&) @ 0x000000000d3a3ec7 8. /build/src/Functions/FunctionBinaryArithmetic.h:844: DB::FunctionBinaryArithmetic::executeImpl2(std::vector> const&, std::shared_ptr const&, unsigned long, DB::PODArray, 63ul, 64ul> const*) const @ 0x000000000d3a03c5 9. /build/src/Functions/FunctionBinaryArithmetic.h:2410: DB::FunctionBinaryArithmetic::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000d39e94c 10. /build/src/Functions/FunctionBinaryArithmetic.h:2645: DB::FunctionBinaryArithmeticWithConstants::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000d39dbd4 11. /build/src/Functions/IFunctionAdaptors.cpp:10: DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000012d995fa 12. /build/src/Functions/IFunction.cpp:353: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d93b52 13. /build/src/Functions/IFunction.cpp:420: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d95059 14. /build/src/Functions/IFunction.cpp:498: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d95c72 15. /build/src/Interpreters/ExpressionActions.cpp:636: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x00000000145176f3 16. /build/src/Processors/Transforms/ExpressionTransform.cpp:25: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x0000000016c0b34c 17. /build/src/Processors/ISimpleTransform.h:33: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000011a9a453 18. /build/src/Processors/ISimpleTransform.cpp:89: DB::ISimpleTransform::work() @ 0x000000001699fca0 19. /build/src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x00000000169bd00f 20. /build/src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x00000000169b2105 21. /build/src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeSingleThread(unsigned long) @ 0x00000000169b23be 22. /build/src/Processors/Executors/PipelineExecutor.cpp:454: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x00000000169b0be7 23. /build/src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x00000000169b03f4 24. /build/src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:se190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169bfeab 25. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc3d92 26. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fcca080 27. ? @ 0x00007fbc6213eac3 28. ? @ 0x00007fbc621d0850 2025.07.28 11:53:47.330386 [ 17256 ] {} TCPHandler: Code: 153. DB::Exception: Division by zero: while executing 'FUNCTION modulo(1_UInt8 :: 1, modulo(plus(__table1.number, 500_UInt16), 1000_UInt16) :: 2) -> modulo(1_UInt8, modulo(plus(__table1.number, 500_UInt16), 1000_UInt16)) UInt16 : 3'. (ILLEGAL_DIVISION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000000a074fcb 4. /build/src/Functions/DivisionUtils.h:26: void DB::impl_::BinaryOperation, unsigned short>::process<(DB::impl_::OpCase)1>(char8_t const*, unsigned short const*, unsigned short*, unsigned long, DB::PODArray, 63ul, 64ul> const*) @ 0x000000000d184621 5. /build/src/Functions/FunctionBinaryArithmetic.h:2338: COW::immutable_ptr DB::FunctionBinaryArithmetic::executeNumeric, DB::DataTypeNumber>(std::vector> const&, DB::DataTypeNumber const&, DB::DataTypeNumber const&, DB::PODArray, 63ul, 64ul> const*) const @ 0x000000000d3a6416 6. /build/src/Functions/FunctionBinaryArithmetic.h:2508: 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&&) @ 0x000000000d3a4a68 7. /build/src/Functions/FunctionBinaryArithmetic.h:846: 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&&) @ 0x000000000d3a3ec7 8. /build/src/Functions/FunctionBinaryArithmetic.h:844: DB::FunctionBinaryArithmetic::executeImpl2(std::vector> const&, std::shared_ptr const&, unsigned long, DB::PODArray, 63ul, 64ul> const*) const @ 0x000000000d3a03c5 9. /build/src/Functions/FunctionBinaryArithmetic.h:2410: DB::FunctionBinaryArithmetic::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000d39e94c 10. /build/src/Functions/FunctionBinaryArithmetic.h:2645: DB::FunctionBinaryArithmeticWithConstants::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000d39dbd4 11. /build/src/Functions/IFunctionAdaptors.cpp:10: DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000012d995fa 12. /build/src/Functions/IFunction.cpp:353: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d93b52 13. /build/src/Functions/IFunction.cpp:420: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d95059 14. /build/src/Functions/IFunction.cpp:498: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d95c72 15. /build/src/Interpreters/ExpressionActions.cpp:636: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x00000000145176f3 16. /build/src/Processors/Transforms/ExpressionTransform.cpp:25: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x0000000016c0b34c 17. /build/src/Processors/ISimpleTransform.h:33: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000011a9a453 18. /build/src/Processors/ISimpleTransform.cpp:89: DB::ISimpleTransform::work() @ 0x000000001699fca0 19. /build/src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x00000000169bd00f 20. /build/src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x00000000169b2105 21. /build/src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeSingleThread(unsigned long) @ 0x00000000169b23be 22. /build/src/Processors/Executors/PipelineExecutor.cpp:454: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x00000000169b0be7 23. /build/src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x00000000169b03f4 24. /build/src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:se190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169bfeab 25. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc3d92 26. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fcca080 27. ? @ 0x00007fbc6213eac3 28. ? @ 0x00007fbc621d0850 Job's origin stack trace: 0. /build/src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000000fc33b84 1. /build/src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000000fcc2ea7 2. /build/src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fcc535c 3. /build/src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000000fcc584d 4. /build/src/Common/ThreadPool.h:279: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x00000000169bf193 5. /build/src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x00000000169bf518 6. /build/src/Server/TCPHandler.cpp:1237: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x00000000168f1525 7. /build/src/Server/TCPHandler.cpp:678: DB::TCPHandler::runImpl() @ 0x00000000168e68e5 8. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 9. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 10. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 11. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 12. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 13. ? @ 0x00007fbc6213eac3 14. ? @ 0x00007fbc621d0850 2025.07.28 11:53:47.628590 [ 3968 ] {} test_13.rmt2 (7f9b740d-015c-470e-8cc6-8ba33be0dc63): auto DB::StorageReplicatedMergeTree::processQueueEntry(ReplicatedMergeTreeQueue::SelectedEntryPtr)::(anonymous class)::operator()(LogEntryPtr &) const: Code: 86. DB::HTTPException: Received error from remote server http://146b4357c08d:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Ftest%2F01165%2Ftest_13%2Frmt%2Freplicas%2F1&part=20250728_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.6.10636.altinitytest (altinity build)) '. (RECEIVED_ERROR_FROM_REMOTE_IO_SERVER), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.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 const&, int&&, String const&, unsigned long&&, String const&) @ 0x000000000feda8d9 4. /build/src/IO/HTTPCommon.cpp:104: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x000000000feda6e2 5. /build/src/IO/HTTPCommon.cpp:93: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x000000000feda537 6. /build/src/IO/ReadWriteBufferFromHTTP.cpp:277: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x000000001184a4c4 7. /build/src/IO/ReadWriteBufferFromHTTP.cpp:285: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x000000001184a615 8. /build/src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x000000001184ae59 9. /build/src/IO/ReadWriteBufferFromHTTP.cpp:472: void std::__function::__policy_invoker::__call_impl[abi:se190107]>(std::__function::__policy_storage const*) @ 0x000000001184cedd 10. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001184858b 11. /build/src/IO/ReadWriteBufferFromHTTP.cpp:465: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x000000001184bf0b 12. /build/src/IO/ReadBuffer.h:60: DB::ReadBuffer::next() @ 0x000000000a148c7b 13. /build/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) @ 0x0000000011849fb2 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]>&)>&, 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&) @ 0x0000000011841980 15. /build/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) @ 0x000000001621208e 16. /build/src/Storages/StorageReplicatedMergeTree.cpp:5228: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl[abi:se190107] const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000015f9a5fe 17. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000015ed8bfd 18. /build/src/Storages/StorageReplicatedMergeTree.cpp:2514: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x0000000015ec9aab 19. /build/src/Storages/StorageReplicatedMergeTree.cpp:2349: DB::StorageReplicatedMergeTree::executeLogEntry(DB::ReplicatedMergeTreeLogEntry&) @ 0x0000000015eba91b 20. /build/src/Storages/StorageReplicatedMergeTree.cpp:3876: bool std::__function::__policy_invoker&)>::__call_impl[abi:se190107])::$_1, bool (std::shared_ptr&)>>(std::__function::__policy_storage const*, std::shared_ptr&) @ 0x0000000015f9837e 21. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000165d6fc3 22. /build/src/Storages/StorageReplicatedMergeTree.cpp:3872: DB::StorageReplicatedMergeTree::processQueueEntry(std::shared_ptr) @ 0x0000000015efc18a 23. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001624c1b2 24. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000162f9c70 25. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x00000000162fa55a 26. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc6653 27. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000000fccc4c3 28. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc3d92 29. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fcca080 30. ? @ 0x00007fbc6213eac3 31. ? @ 0x00007fbc621d0850 (version 25.3.6.10636.altinitytest (altinity build)) 2025.07.28 11:53:47.659766 [ 17557 ] {be415e7f-0cf8-4966-b086-3cf03a3dcceb} executeQuery: Code: 236. DB::NetException: Client has dropped the connection, cancel the query. (ABORTED) (version 25.3.6.10636.altinitytest (altinity build)) (from [::1]:46610) (comment: 03352_concurrent_rename_alter.sh) (query 1, line 1) (in query: INSERT INTO t_rename_alter (id, dt, arr_v2) SELECT 1, now(), [(now(), 1, 'a', 'b', 'c')]), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::NetException::NetException(int, T&&) @ 0x0000000016900f80 3. /build/src/Server/TCPHandler.cpp:2426: DB::TCPHandler::receivePacketsExpectCancel(DB::QueryState&) @ 0x00000000168fba18 4. /build/src/Server/TCPHandler.cpp:693: bool std::__function::__policy_invoker::__call_impl[abi:se190107]>(std::__function::__policy_storage const*) @ 0x0000000016900715 5. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000169af42e 6. /build/src/Server/TCPHandler.cpp:707: DB::TCPHandler::runImpl() @ 0x00000000168e6b2e 7. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 8. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 9. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 10. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 11. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 12. ? @ 0x00007fbc6213eac3 13. ? @ 0x00007fbc621d0850 2025.07.28 11:53:47.754974 [ 17557 ] {be415e7f-0cf8-4966-b086-3cf03a3dcceb} 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]:46610). (NETWORK_ERROR), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::NetException::NetException(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&) @ 0x000000000fd50fb5 3. /build/src/IO/WriteBufferFromPocoSocket.cpp:171: DB::WriteBufferFromPocoSocket::nextImpl() @ 0x000000000fd525a7 4. /build/src/IO/WriteBuffer.h:53: DB::WriteBuffer::next() @ 0x000000000a0755be 5. /build/src/Server/TCPHandler.cpp:826: DB::TCPHandler::runImpl() @ 0x00000000168e6c9c 6. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 7. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 8. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 9. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 10. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 11. ? @ 0x00007fbc6213eac3 12. ? @ 0x00007fbc621d0850 (version 25.3.6.10636.altinitytest (altinity build)) 2025.07.28 11:53:47.757693 [ 17557 ] {} 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. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::NetException::NetException(int, T&&) @ 0x0000000016900f80 3. /build/src/Server/TCPHandler.cpp:2426: DB::TCPHandler::receivePacketsExpectCancel(DB::QueryState&) @ 0x00000000168fba18 4. /build/src/Server/TCPHandler.cpp:693: bool std::__function::__policy_invoker::__call_impl[abi:se190107]>(std::__function::__policy_storage const*) @ 0x0000000016900715 5. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000169af42e 6. /build/src/Server/TCPHandler.cpp:707: DB::TCPHandler::runImpl() @ 0x00000000168e6b2e 7. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 8. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 9. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 10. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 11. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 12. ? @ 0x00007fbc6213eac3 13. ? @ 0x00007fbc621d0850 2025.07.28 11:53:47.806346 [ 12807 ] {2460ed59-2936-42c2-8955-ec3b60a5037f} 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_8026413088567456626_16134285162946906920 :: 2) -> in(tuple(__table1.s, __table1.d, __table1.s), __set_8026413088567456626_16134285162946906920) UInt8 : 1'. (NUMBER_OF_COLUMNS_DOESNT_MATCH) (version 25.3.6.10636.altinitytest (altinity build)) (from [::1]:46638) (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. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, unsigned long&, unsigned long&&) @ 0x000000000a0fb82b 4. /build/src/Interpreters/Set.cpp:602: DB::Set::checkColumnsNumber(unsigned long) const @ 0x0000000014a843a9 5. /build/src/Interpreters/Set.cpp:412: DB::Set::execute(std::vector> const&, bool) const @ 0x0000000014a83437 6. /build/src/Functions/in.cpp:174: DB::(anonymous namespace)::FunctionIn::executeImpl(std::vector> const&, bool, unsigned long) const @ 0x000000000c26b83d 7. /build/src/Functions/in.cpp:102: DB::(anonymous namespace)::FunctionIn::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000c26af0b 8. /build/src/Functions/IFunctionAdaptors.cpp:10: DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000012d995fa 9. /build/src/Functions/IFunction.cpp:353: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d93b52 10. /build/src/Functions/IFunction.cpp:420: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d95059 11. /build/src/Functions/IFunction.cpp:498: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d95c72 12. /build/src/Interpreters/ExpressionActions.cpp:636: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x00000000145176f3 13. /build/src/Processors/Transforms/FilterTransform.cpp:142: DB::FilterTransform::doTransform(DB::Chunk&) @ 0x0000000016c0f114 14. /build/src/Processors/Transforms/FilterTransform.cpp:126: DB::FilterTransform::transform(DB::Chunk&) @ 0x0000000016c0f034 15. /build/src/Processors/ISimpleTransform.h:33: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000011a9a453 16. /build/src/Processors/ISimpleTransform.cpp:89: DB::ISimpleTransform::work() @ 0x000000001699fca0 17. /build/src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x00000000169bd00f 18. /build/src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x00000000169b2105 19. /build/src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeSingleThread(unsigned long) @ 0x00000000169b23be 20. /build/src/Processors/Executors/PipelineExecutor.cpp:454: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x00000000169b0be7 21. /build/src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x00000000169b03f4 22. /build/src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:se190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169bfeab 23. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc3d92 24. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fcca080 25. ? @ 0x00007fbc6213eac3 26. ? @ 0x00007fbc621d0850 2025.07.28 11:53:47.820197 [ 12807 ] {} 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_8026413088567456626_16134285162946906920 :: 2) -> in(tuple(__table1.s, __table1.d, __table1.s), __set_8026413088567456626_16134285162946906920) UInt8 : 1'. (NUMBER_OF_COLUMNS_DOESNT_MATCH), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, unsigned long&, unsigned long&&) @ 0x000000000a0fb82b 4. /build/src/Interpreters/Set.cpp:602: DB::Set::checkColumnsNumber(unsigned long) const @ 0x0000000014a843a9 5. /build/src/Interpreters/Set.cpp:412: DB::Set::execute(std::vector> const&, bool) const @ 0x0000000014a83437 6. /build/src/Functions/in.cpp:174: DB::(anonymous namespace)::FunctionIn::executeImpl(std::vector> const&, bool, unsigned long) const @ 0x000000000c26b83d 7. /build/src/Functions/in.cpp:102: DB::(anonymous namespace)::FunctionIn::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000c26af0b 8. /build/src/Functions/IFunctionAdaptors.cpp:10: DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000012d995fa 9. /build/src/Functions/IFunction.cpp:353: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d93b52 10. /build/src/Functions/IFunction.cpp:420: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d95059 11. /build/src/Functions/IFunction.cpp:498: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d95c72 12. /build/src/Interpreters/ExpressionActions.cpp:636: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x00000000145176f3 13. /build/src/Processors/Transforms/FilterTransform.cpp:142: DB::FilterTransform::doTransform(DB::Chunk&) @ 0x0000000016c0f114 14. /build/src/Processors/Transforms/FilterTransform.cpp:126: DB::FilterTransform::transform(DB::Chunk&) @ 0x0000000016c0f034 15. /build/src/Processors/ISimpleTransform.h:33: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000011a9a453 16. /build/src/Processors/ISimpleTransform.cpp:89: DB::ISimpleTransform::work() @ 0x000000001699fca0 17. /build/src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x00000000169bd00f 18. /build/src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x00000000169b2105 19. /build/src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeSingleThread(unsigned long) @ 0x00000000169b23be 20. /build/src/Processors/Executors/PipelineExecutor.cpp:454: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x00000000169b0be7 21. /build/src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x00000000169b03f4 22. /build/src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:se190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169bfeab 23. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc3d92 24. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fcca080 25. ? @ 0x00007fbc6213eac3 26. ? @ 0x00007fbc621d0850 Job's origin stack trace: 0. /build/src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000000fc33b84 1. /build/src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000000fcc2ea7 2. /build/src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fcc535c 3. /build/src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000000fcc584d 4. /build/src/Common/ThreadPool.h:279: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x00000000169bf193 5. /build/src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x00000000169bf518 6. /build/src/Server/TCPHandler.cpp:1237: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x00000000168f1525 7. /build/src/Server/TCPHandler.cpp:678: DB::TCPHandler::runImpl() @ 0x00000000168e68e5 8. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 9. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 10. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 11. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 12. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 13. ? @ 0x00007fbc6213eac3 14. ? @ 0x00007fbc621d0850 2025.07.28 11:53:47.907502 [ 3963 ] {} test_13.rmt2 (7f9b740d-015c-470e-8cc6-8ba33be0dc63): auto DB::StorageReplicatedMergeTree::processQueueEntry(ReplicatedMergeTreeQueue::SelectedEntryPtr)::(anonymous class)::operator()(LogEntryPtr &) const: Code: 86. DB::HTTPException: Received error from remote server http://146b4357c08d:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Ftest%2F01165%2Ftest_13%2Frmt%2Freplicas%2F1&part=20250728_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.6.10636.altinitytest (altinity build)) '. (RECEIVED_ERROR_FROM_REMOTE_IO_SERVER), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.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 const&, int&&, String const&, unsigned long&&, String const&) @ 0x000000000feda8d9 4. /build/src/IO/HTTPCommon.cpp:104: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x000000000feda6e2 5. /build/src/IO/HTTPCommon.cpp:93: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x000000000feda537 6. /build/src/IO/ReadWriteBufferFromHTTP.cpp:277: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x000000001184a4c4 7. /build/src/IO/ReadWriteBufferFromHTTP.cpp:285: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x000000001184a615 8. /build/src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x000000001184ae59 9. /build/src/IO/ReadWriteBufferFromHTTP.cpp:472: void std::__function::__policy_invoker::__call_impl[abi:se190107]>(std::__function::__policy_storage const*) @ 0x000000001184cedd 10. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001184858b 11. /build/src/IO/ReadWriteBufferFromHTTP.cpp:465: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x000000001184bf0b 12. /build/src/IO/ReadBuffer.h:60: DB::ReadBuffer::next() @ 0x000000000a148c7b 13. /build/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) @ 0x0000000011849fb2 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]>&)>&, 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&) @ 0x0000000011841980 15. /build/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) @ 0x000000001621208e 16. /build/src/Storages/StorageReplicatedMergeTree.cpp:5228: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl[abi:se190107] const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000015f9a5fe 17. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000015ed8bfd 18. /build/src/Storages/StorageReplicatedMergeTree.cpp:2514: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x0000000015ec9aab 19. /build/src/Storages/StorageReplicatedMergeTree.cpp:2349: DB::StorageReplicatedMergeTree::executeLogEntry(DB::ReplicatedMergeTreeLogEntry&) @ 0x0000000015eba91b 20. /build/src/Storages/StorageReplicatedMergeTree.cpp:3876: bool std::__function::__policy_invoker&)>::__call_impl[abi:se190107])::$_1, bool (std::shared_ptr&)>>(std::__function::__policy_storage const*, std::shared_ptr&) @ 0x0000000015f9837e 21. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000165d6fc3 22. /build/src/Storages/StorageReplicatedMergeTree.cpp:3872: DB::StorageReplicatedMergeTree::processQueueEntry(std::shared_ptr) @ 0x0000000015efc18a 23. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001624c1b2 24. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000162f9c70 25. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x00000000162fa55a 26. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc6653 27. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000000fccc4c3 28. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc3d92 29. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fcca080 30. ? @ 0x00007fbc6213eac3 31. ? @ 0x00007fbc621d0850 (version 25.3.6.10636.altinitytest (altinity build)) 2025.07.28 11:53:48.325581 [ 5747 ] {e74de5d3-a6c5-47c9-9821-e4be02e934c4} 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_12080824259098991421_8592582687044103844 :: 2) -> in(tuple(__table1.s, __table1.d), __set_12080824259098991421_8592582687044103844) UInt8 : 0'. (NUMBER_OF_COLUMNS_DOESNT_MATCH) (version 25.3.6.10636.altinitytest (altinity build)) (from [::1]:46672) (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. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, unsigned long&, unsigned long&&) @ 0x000000000a0fb82b 4. /build/src/Interpreters/Set.cpp:602: DB::Set::checkColumnsNumber(unsigned long) const @ 0x0000000014a843a9 5. /build/src/Interpreters/Set.cpp:412: DB::Set::execute(std::vector> const&, bool) const @ 0x0000000014a83437 6. /build/src/Functions/in.cpp:174: DB::(anonymous namespace)::FunctionIn::executeImpl(std::vector> const&, bool, unsigned long) const @ 0x000000000c26b83d 7. /build/src/Functions/in.cpp:102: DB::(anonymous namespace)::FunctionIn::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000c26af0b 8. /build/src/Functions/IFunctionAdaptors.cpp:10: DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000012d995fa 9. /build/src/Functions/IFunction.cpp:353: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d93b52 10. /build/src/Functions/IFunction.cpp:420: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d95059 11. /build/src/Functions/IFunction.cpp:498: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d95c72 12. /build/src/Interpreters/ExpressionActions.cpp:636: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x00000000145176f3 13. /build/src/Processors/Transforms/FilterTransform.cpp:142: DB::FilterTransform::doTransform(DB::Chunk&) @ 0x0000000016c0f114 14. /build/src/Processors/Transforms/FilterTransform.cpp:126: DB::FilterTransform::transform(DB::Chunk&) @ 0x0000000016c0f034 15. /build/src/Processors/ISimpleTransform.h:33: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000011a9a453 16. /build/src/Processors/ISimpleTransform.cpp:89: DB::ISimpleTransform::work() @ 0x000000001699fca0 17. /build/src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x00000000169bd00f 18. /build/src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x00000000169b2105 19. /build/src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeSingleThread(unsigned long) @ 0x00000000169b23be 20. /build/src/Processors/Executors/PipelineExecutor.cpp:454: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x00000000169b0be7 21. /build/src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x00000000169b03f4 22. /build/src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:se190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169bfeab 23. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc3d92 24. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fcca080 25. ? @ 0x00007fbc6213eac3 26. ? @ 0x00007fbc621d0850 2025.07.28 11:53:48.375991 [ 5747 ] {} 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_12080824259098991421_8592582687044103844 :: 2) -> in(tuple(__table1.s, __table1.d), __set_12080824259098991421_8592582687044103844) UInt8 : 0'. (NUMBER_OF_COLUMNS_DOESNT_MATCH), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, unsigned long&, unsigned long&&) @ 0x000000000a0fb82b 4. /build/src/Interpreters/Set.cpp:602: DB::Set::checkColumnsNumber(unsigned long) const @ 0x0000000014a843a9 5. /build/src/Interpreters/Set.cpp:412: DB::Set::execute(std::vector> const&, bool) const @ 0x0000000014a83437 6. /build/src/Functions/in.cpp:174: DB::(anonymous namespace)::FunctionIn::executeImpl(std::vector> const&, bool, unsigned long) const @ 0x000000000c26b83d 7. /build/src/Functions/in.cpp:102: DB::(anonymous namespace)::FunctionIn::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000c26af0b 8. /build/src/Functions/IFunctionAdaptors.cpp:10: DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000012d995fa 9. /build/src/Functions/IFunction.cpp:353: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d93b52 10. /build/src/Functions/IFunction.cpp:420: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d95059 11. /build/src/Functions/IFunction.cpp:498: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d95c72 12. /build/src/Interpreters/ExpressionActions.cpp:636: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x00000000145176f3 13. /build/src/Processors/Transforms/FilterTransform.cpp:142: DB::FilterTransform::doTransform(DB::Chunk&) @ 0x0000000016c0f114 14. /build/src/Processors/Transforms/FilterTransform.cpp:126: DB::FilterTransform::transform(DB::Chunk&) @ 0x0000000016c0f034 15. /build/src/Processors/ISimpleTransform.h:33: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000011a9a453 16. /build/src/Processors/ISimpleTransform.cpp:89: DB::ISimpleTransform::work() @ 0x000000001699fca0 17. /build/src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x00000000169bd00f 18. /build/src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x00000000169b2105 19. /build/src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeSingleThread(unsigned long) @ 0x00000000169b23be 20. /build/src/Processors/Executors/PipelineExecutor.cpp:454: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x00000000169b0be7 21. /build/src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x00000000169b03f4 22. /build/src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:se190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169bfeab 23. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc3d92 24. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fcca080 25. ? @ 0x00007fbc6213eac3 26. ? @ 0x00007fbc621d0850 Job's origin stack trace: 0. /build/src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000000fc33b84 1. /build/src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000000fcc2ea7 2. /build/src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fcc535c 3. /build/src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000000fcc584d 4. /build/src/Common/ThreadPool.h:279: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x00000000169bf193 5. /build/src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x00000000169bf518 6. /build/src/Server/TCPHandler.cpp:1237: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x00000000168f1525 7. /build/src/Server/TCPHandler.cpp:678: DB::TCPHandler::runImpl() @ 0x00000000168e68e5 8. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 9. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 10. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 11. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 12. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 13. ? @ 0x00007fbc6213eac3 14. ? @ 0x00007fbc621d0850 2025.07.28 11:53:48.405614 [ 3976 ] {} test_13.rmt2 (7f9b740d-015c-470e-8cc6-8ba33be0dc63): auto DB::StorageReplicatedMergeTree::processQueueEntry(ReplicatedMergeTreeQueue::SelectedEntryPtr)::(anonymous class)::operator()(LogEntryPtr &) const: Code: 86. DB::HTTPException: Received error from remote server http://146b4357c08d:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Ftest%2F01165%2Ftest_13%2Frmt%2Freplicas%2F1&part=20250728_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.6.10636.altinitytest (altinity build)) '. (RECEIVED_ERROR_FROM_REMOTE_IO_SERVER), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.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 const&, int&&, String const&, unsigned long&&, String const&) @ 0x000000000feda8d9 4. /build/src/IO/HTTPCommon.cpp:104: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x000000000feda6e2 5. /build/src/IO/HTTPCommon.cpp:93: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x000000000feda537 6. /build/src/IO/ReadWriteBufferFromHTTP.cpp:277: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x000000001184a4c4 7. /build/src/IO/ReadWriteBufferFromHTTP.cpp:285: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x000000001184a615 8. /build/src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x000000001184ae59 9. /build/src/IO/ReadWriteBufferFromHTTP.cpp:472: void std::__function::__policy_invoker::__call_impl[abi:se190107]>(std::__function::__policy_storage const*) @ 0x000000001184cedd 10. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001184858b 11. /build/src/IO/ReadWriteBufferFromHTTP.cpp:465: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x000000001184bf0b 12. /build/src/IO/ReadBuffer.h:60: DB::ReadBuffer::next() @ 0x000000000a148c7b 13. /build/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) @ 0x0000000011849fb2 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]>&)>&, 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&) @ 0x0000000011841980 15. /build/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) @ 0x000000001621208e 16. /build/src/Storages/StorageReplicatedMergeTree.cpp:5228: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl[abi:se190107] const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000015f9a5fe 17. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000015ed8bfd 18. /build/src/Storages/StorageReplicatedMergeTree.cpp:2514: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x0000000015ec9aab 19. /build/src/Storages/StorageReplicatedMergeTree.cpp:2349: DB::StorageReplicatedMergeTree::executeLogEntry(DB::ReplicatedMergeTreeLogEntry&) @ 0x0000000015eba91b 20. /build/src/Storages/StorageReplicatedMergeTree.cpp:3876: bool std::__function::__policy_invoker&)>::__call_impl[abi:se190107])::$_1, bool (std::shared_ptr&)>>(std::__function::__policy_storage const*, std::shared_ptr&) @ 0x0000000015f9837e 21. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000165d6fc3 22. /build/src/Storages/StorageReplicatedMergeTree.cpp:3872: DB::StorageReplicatedMergeTree::processQueueEntry(std::shared_ptr) @ 0x0000000015efc18a 23. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001624c1b2 24. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000162f9c70 25. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x00000000162fa55a 26. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc6653 27. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000000fccc4c3 28. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc3d92 29. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fcca080 30. ? @ 0x00007fbc6213eac3 31. ? @ 0x00007fbc621d0850 (version 25.3.6.10636.altinitytest (altinity build)) 2025.07.28 11:53:49.346159 [ 3971 ] {} test_13.rmt2 (7f9b740d-015c-470e-8cc6-8ba33be0dc63): auto DB::StorageReplicatedMergeTree::processQueueEntry(ReplicatedMergeTreeQueue::SelectedEntryPtr)::(anonymous class)::operator()(LogEntryPtr &) const: Code: 86. DB::HTTPException: Received error from remote server http://146b4357c08d:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Ftest%2F01165%2Ftest_13%2Frmt%2Freplicas%2F1&part=20250728_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.6.10636.altinitytest (altinity build)) '. (RECEIVED_ERROR_FROM_REMOTE_IO_SERVER), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.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 const&, int&&, String const&, unsigned long&&, String const&) @ 0x000000000feda8d9 4. /build/src/IO/HTTPCommon.cpp:104: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x000000000feda6e2 5. /build/src/IO/HTTPCommon.cpp:93: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x000000000feda537 6. /build/src/IO/ReadWriteBufferFromHTTP.cpp:277: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x000000001184a4c4 7. /build/src/IO/ReadWriteBufferFromHTTP.cpp:285: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x000000001184a615 8. /build/src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x000000001184ae59 9. /build/src/IO/ReadWriteBufferFromHTTP.cpp:472: void std::__function::__policy_invoker::__call_impl[abi:se190107]>(std::__function::__policy_storage const*) @ 0x000000001184cedd 10. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001184858b 11. /build/src/IO/ReadWriteBufferFromHTTP.cpp:465: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x000000001184bf0b 12. /build/src/IO/ReadBuffer.h:60: DB::ReadBuffer::next() @ 0x000000000a148c7b 13. /build/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) @ 0x0000000011849fb2 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]>&)>&, 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&) @ 0x0000000011841980 15. /build/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) @ 0x000000001621208e 16. /build/src/Storages/StorageReplicatedMergeTree.cpp:5228: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl[abi:se190107] const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000015f9a5fe 17. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000015ed8bfd 18. /build/src/Storages/StorageReplicatedMergeTree.cpp:2514: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x0000000015ec9aab 19. /build/src/Storages/StorageReplicatedMergeTree.cpp:2349: DB::StorageReplicatedMergeTree::executeLogEntry(DB::ReplicatedMergeTreeLogEntry&) @ 0x0000000015eba91b 20. /build/src/Storages/StorageReplicatedMergeTree.cpp:3876: bool std::__function::__policy_invoker&)>::__call_impl[abi:se190107])::$_1, bool (std::shared_ptr&)>>(std::__function::__policy_storage const*, std::shared_ptr&) @ 0x0000000015f9837e 21. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000165d6fc3 22. /build/src/Storages/StorageReplicatedMergeTree.cpp:3872: DB::StorageReplicatedMergeTree::processQueueEntry(std::shared_ptr) @ 0x0000000015efc18a 23. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001624c1b2 24. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000162f9c70 25. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x00000000162fa55a 26. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc6653 27. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000000fccc4c3 28. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc3d92 29. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fcca080 30. ? @ 0x00007fbc6213eac3 31. ? @ 0x00007fbc621d0850 (version 25.3.6.10636.altinitytest (altinity build)) 2025.07.28 11:53:49.899976 [ 3965 ] {} test_13.rmt2 (7f9b740d-015c-470e-8cc6-8ba33be0dc63): auto DB::StorageReplicatedMergeTree::processQueueEntry(ReplicatedMergeTreeQueue::SelectedEntryPtr)::(anonymous class)::operator()(LogEntryPtr &) const: Code: 86. DB::HTTPException: Received error from remote server http://146b4357c08d:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Ftest%2F01165%2Ftest_13%2Frmt%2Freplicas%2F1&part=20250728_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.6.10636.altinitytest (altinity build)) '. (RECEIVED_ERROR_FROM_REMOTE_IO_SERVER), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.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 const&, int&&, String const&, unsigned long&&, String const&) @ 0x000000000feda8d9 4. /build/src/IO/HTTPCommon.cpp:104: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x000000000feda6e2 5. /build/src/IO/HTTPCommon.cpp:93: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x000000000feda537 6. /build/src/IO/ReadWriteBufferFromHTTP.cpp:277: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x000000001184a4c4 7. /build/src/IO/ReadWriteBufferFromHTTP.cpp:285: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x000000001184a615 8. /build/src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x000000001184ae59 9. /build/src/IO/ReadWriteBufferFromHTTP.cpp:472: void std::__function::__policy_invoker::__call_impl[abi:se190107]>(std::__function::__policy_storage const*) @ 0x000000001184cedd 10. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001184858b 11. /build/src/IO/ReadWriteBufferFromHTTP.cpp:465: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x000000001184bf0b 12. /build/src/IO/ReadBuffer.h:60: DB::ReadBuffer::next() @ 0x000000000a148c7b 13. /build/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) @ 0x0000000011849fb2 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]>&)>&, 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&) @ 0x0000000011841980 15. /build/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) @ 0x000000001621208e 16. /build/src/Storages/StorageReplicatedMergeTree.cpp:5228: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl[abi:se190107] const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000015f9a5fe 17. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000015ed8bfd 18. /build/src/Storages/StorageReplicatedMergeTree.cpp:2514: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x0000000015ec9aab 19. /build/src/Storages/StorageReplicatedMergeTree.cpp:2349: DB::StorageReplicatedMergeTree::executeLogEntry(DB::ReplicatedMergeTreeLogEntry&) @ 0x0000000015eba91b 20. /build/src/Storages/StorageReplicatedMergeTree.cpp:3876: bool std::__function::__policy_invoker&)>::__call_impl[abi:se190107])::$_1, bool (std::shared_ptr&)>>(std::__function::__policy_storage const*, std::shared_ptr&) @ 0x0000000015f9837e 21. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000165d6fc3 22. /build/src/Storages/StorageReplicatedMergeTree.cpp:3872: DB::StorageReplicatedMergeTree::processQueueEntry(std::shared_ptr) @ 0x0000000015efc18a 23. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001624c1b2 24. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000162f9c70 25. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x00000000162fa55a 26. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc6653 27. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000000fccc4c3 28. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc3d92 29. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fcca080 30. ? @ 0x00007fbc6213eac3 31. ? @ 0x00007fbc621d0850 (version 25.3.6.10636.altinitytest (altinity build)) 2025.07.28 11:53:49.981903 [ 5959 ] {} ExternalDictionariesLoader: Could not load external dictionary 'cc8b1a52-da70-449c-9c23-8d623c5fcc44', next update is scheduled at 2025-07-28 11:54:10: Code: 396. DB::Exception: Limit for result exceeded, max bytes: 1.00 B, current bytes: 36.00 B. (TOO_MANY_ROWS_OR_BYTES), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, char const*&, ReadableSize&&, ReadableSize&&) @ 0x0000000013bd4eeb 4. /build/src/QueryPipeline/SizeLimits.cpp:43: DB::SizeLimits::check(unsigned long, unsigned long, char const*, int, int) const @ 0x0000000013bd48a1 5. /build/src/Processors/Transforms/LimitsCheckingTransform.cpp:45: DB::LimitsCheckingTransform::transform(DB::Chunk&) @ 0x0000000016c1d2fb 6. /build/src/Processors/ISimpleTransform.h:33: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000011a9a453 7. /build/src/Processors/ISimpleTransform.cpp:89: DB::ISimpleTransform::work() @ 0x000000001699fca0 8. /build/src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x00000000169bd00f 9. /build/src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x00000000169b2105 10. /build/src/Processors/Executors/PipelineExecutor.cpp:170: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x00000000169b16a7 11. /build/src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x00000000169c081c 12. /build/src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x00000000169c0978 13. /build/src/Dictionaries/FlatDictionary.cpp:502: DB::FlatDictionary::loadData() @ 0x0000000011b424cb 14. /build/src/Dictionaries/FlatDictionary.cpp:46: DB::FlatDictionary::FlatDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, DB::FlatDictionary::Configuration, std::shared_ptr) @ 0x0000000011b42111 15. /build/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:se190107]> (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) @ 0x0000000011b5d3e2 16. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000012d8a61d 17. /build/src/Interpreters/ExternalDictionariesLoader.cpp:47: DB::ExternalDictionariesLoader::createObject(String const&, Poco::Util::AbstractConfiguration const&, String const&, String const&) const @ 0x00000000148a6f44 18. /build/src/Interpreters/ExternalLoader.cpp:1522: DB::ExternalLoader::LoadingDispatcher::loadSingleObject(String const&, DB::ExternalLoader::ObjectConfig const&, std::shared_ptr) @ 0x00000000148b2ee8 19. /build/src/Interpreters/ExternalLoader.cpp:998: DB::ExternalLoader::LoadingDispatcher::doLoading(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr) @ 0x00000000148b197d 20. /build/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()() @ 0x00000000148b5991 21. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc3d92 22. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fcca080 23. ? @ 0x00007fbc6213eac3 24. ? @ 0x00007fbc621d0850 (version 25.3.6.10636.altinitytest (altinity build)) 2025.07.28 11:53:50.559798 [ 17557 ] {8a2f4c3e-b4d1-4129-a178-005cd2ed3954} executeQuery: Code: 455. DB::Exception: Creating columns of type LowCardinality(Int128) 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('{}', 'JSON(a LowCardinality(Int128))'). (SUSPICIOUS_TYPE_FOR_LOW_CARDINALITY) (version 25.3.6.10636.altinitytest (altinity build)) (from [::1]:46738) (comment: 03261_json_hints_types_check.sql) (query 4, line 5) (in query: select '{}'::JSON(a LowCardinality(Int128));), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x000000000a06b56b 4. /build/src/Interpreters/parseColumnsListForTableFunction.cpp:67: DB::validateDataType(std::shared_ptr const&, DB::DataTypeValidationSettings const&)::$_0::operator()(DB::IDataType const&) const @ 0x0000000014ccea0b 5. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000013bfdcfa 6. /build/src/Interpreters/parseColumnsListForTableFunction.cpp:173: DB::validateDataType(std::shared_ptr const&, DB::DataTypeValidationSettings const&) @ 0x0000000014ccde2d 7. /build/src/Functions/CastOverloadResolver.cpp:128: DB::CastOverloadResolverImpl::getReturnTypeImpl(std::vector> const&) const @ 0x0000000012dcd4a5 8. /build/src/Functions/IFunction.cpp:645: DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x0000000012d96b0c 9. /build/src/Functions/IFunction.cpp:585: DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x0000000012d9665b 10. /build/src/Functions/IFunction.cpp:606: DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x0000000012d96edc 11. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3544: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000014033cc9 12. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3838: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000014019a9e 13. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3980: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000014018e31 14. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:4304: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000014042fa7 15. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5605: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000014013749 16. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000140127f9 17. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000014011fce 18. /build/src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000001406ce8a 19. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000014973b42 20. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000001497268d 21. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000014974d24 22. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001492924b 23. /build/src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88641 24. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 25. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 26. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 27. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 28. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 29. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 30. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 31. ? @ 0x00007fbc6213eac3 2025.07.28 11:53:50.564282 [ 17557 ] {} TCPHandler: Code: 455. DB::Exception: Creating columns of type LowCardinality(Int128) 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('{}', 'JSON(a LowCardinality(Int128))'). (SUSPICIOUS_TYPE_FOR_LOW_CARDINALITY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x000000000a06b56b 4. /build/src/Interpreters/parseColumnsListForTableFunction.cpp:67: DB::validateDataType(std::shared_ptr const&, DB::DataTypeValidationSettings const&)::$_0::operator()(DB::IDataType const&) const @ 0x0000000014ccea0b 5. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000013bfdcfa 6. /build/src/Interpreters/parseColumnsListForTableFunction.cpp:173: DB::validateDataType(std::shared_ptr const&, DB::DataTypeValidationSettings const&) @ 0x0000000014ccde2d 7. /build/src/Functions/CastOverloadResolver.cpp:128: DB::CastOverloadResolverImpl::getReturnTypeImpl(std::vector> const&) const @ 0x0000000012dcd4a5 8. /build/src/Functions/IFunction.cpp:645: DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x0000000012d96b0c 9. /build/src/Functions/IFunction.cpp:585: DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x0000000012d9665b 10. /build/src/Functions/IFunction.cpp:606: DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x0000000012d96edc 11. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3544: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000014033cc9 12. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3838: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000014019a9e 13. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3980: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000014018e31 14. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:4304: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000014042fa7 15. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5605: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000014013749 16. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000140127f9 17. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000014011fce 18. /build/src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000001406ce8a 19. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000014973b42 20. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000001497268d 21. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000014974d24 22. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001492924b 23. /build/src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88641 24. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 25. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 26. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 27. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 28. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 29. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 30. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 31. ? @ 0x00007fbc6213eac3 2025.07.28 11:53:50.663159 [ 17557 ] {9d9b0f03-0ff7-4d85-b814-880d9af88d13} executeQuery: Code: 44. DB::Exception: Cannot create column with type 'FixedString(100000)' 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('{}', 'JSON(a FixedString(100000))'). (ILLEGAL_COLUMN) (version 25.3.6.10636.altinitytest (altinity build)) (from [::1]:46738) (comment: 03261_json_hints_types_check.sql) (query 5, line 6) (in query: select '{}'::JSON(a FixedString(100000));), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, unsigned long const&) @ 0x000000000a3d916b 4. /build/src/Interpreters/parseColumnsListForTableFunction.cpp:92: DB::validateDataType(std::shared_ptr const&, DB::DataTypeValidationSettings const&)::$_0::operator()(DB::IDataType const&) const @ 0x0000000014cce8bf 5. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000013bfdcfa 6. /build/src/Interpreters/parseColumnsListForTableFunction.cpp:173: DB::validateDataType(std::shared_ptr const&, DB::DataTypeValidationSettings const&) @ 0x0000000014ccde2d 7. /build/src/Functions/CastOverloadResolver.cpp:128: DB::CastOverloadResolverImpl::getReturnTypeImpl(std::vector> const&) const @ 0x0000000012dcd4a5 8. /build/src/Functions/IFunction.cpp:645: DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x0000000012d96b0c 9. /build/src/Functions/IFunction.cpp:585: DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x0000000012d9665b 10. /build/src/Functions/IFunction.cpp:606: DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x0000000012d96edc 11. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3544: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000014033cc9 12. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3838: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000014019a9e 13. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3980: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000014018e31 14. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:4304: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000014042fa7 15. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5605: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000014013749 16. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000140127f9 17. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000014011fce 18. /build/src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000001406ce8a 19. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000014973b42 20. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000001497268d 21. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000014974d24 22. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001492924b 23. /build/src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88641 24. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 25. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 26. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 27. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 28. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 29. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 30. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 31. ? @ 0x00007fbc6213eac3 2025.07.28 11:53:50.673733 [ 17557 ] {} TCPHandler: Code: 44. DB::Exception: Cannot create column with type 'FixedString(100000)' 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('{}', 'JSON(a FixedString(100000))'). (ILLEGAL_COLUMN), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, unsigned long const&) @ 0x000000000a3d916b 4. /build/src/Interpreters/parseColumnsListForTableFunction.cpp:92: DB::validateDataType(std::shared_ptr const&, DB::DataTypeValidationSettings const&)::$_0::operator()(DB::IDataType const&) const @ 0x0000000014cce8bf 5. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000013bfdcfa 6. /build/src/Interpreters/parseColumnsListForTableFunction.cpp:173: DB::validateDataType(std::shared_ptr const&, DB::DataTypeValidationSettings const&) @ 0x0000000014ccde2d 7. /build/src/Functions/CastOverloadResolver.cpp:128: DB::CastOverloadResolverImpl::getReturnTypeImpl(std::vector> const&) const @ 0x0000000012dcd4a5 8. /build/src/Functions/IFunction.cpp:645: DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x0000000012d96b0c 9. /build/src/Functions/IFunction.cpp:585: DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x0000000012d9665b 10. /build/src/Functions/IFunction.cpp:606: DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x0000000012d96edc 11. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3544: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000014033cc9 12. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3838: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000014019a9e 13. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3980: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000014018e31 14. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:4304: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000014042fa7 15. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5605: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000014013749 16. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000140127f9 17. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000014011fce 18. /build/src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000001406ce8a 19. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000014973b42 20. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000001497268d 21. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000014974d24 22. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001492924b 23. /build/src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88641 24. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 25. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 26. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 27. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 28. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 29. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 30. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 31. ? @ 0x00007fbc6213eac3 2025.07.28 11:53:50.730884 [ 3964 ] {} test_13.rmt2 (7f9b740d-015c-470e-8cc6-8ba33be0dc63): auto DB::StorageReplicatedMergeTree::processQueueEntry(ReplicatedMergeTreeQueue::SelectedEntryPtr)::(anonymous class)::operator()(LogEntryPtr &) const: Code: 86. DB::HTTPException: Received error from remote server http://146b4357c08d:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Ftest%2F01165%2Ftest_13%2Frmt%2Freplicas%2F1&part=20250728_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.6.10636.altinitytest (altinity build)) '. (RECEIVED_ERROR_FROM_REMOTE_IO_SERVER), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.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 const&, int&&, String const&, unsigned long&&, String const&) @ 0x000000000feda8d9 4. /build/src/IO/HTTPCommon.cpp:104: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x000000000feda6e2 5. /build/src/IO/HTTPCommon.cpp:93: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x000000000feda537 6. /build/src/IO/ReadWriteBufferFromHTTP.cpp:277: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x000000001184a4c4 7. /build/src/IO/ReadWriteBufferFromHTTP.cpp:285: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x000000001184a615 8. /build/src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x000000001184ae59 9. /build/src/IO/ReadWriteBufferFromHTTP.cpp:472: void std::__function::__policy_invoker::__call_impl[abi:se190107]>(std::__function::__policy_storage const*) @ 0x000000001184cedd 10. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001184858b 11. /build/src/IO/ReadWriteBufferFromHTTP.cpp:465: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x000000001184bf0b 12. /build/src/IO/ReadBuffer.h:60: DB::ReadBuffer::next() @ 0x000000000a148c7b 13. /build/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) @ 0x0000000011849fb2 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]>&)>&, 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&) @ 0x0000000011841980 15. /build/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) @ 0x000000001621208e 16. /build/src/Storages/StorageReplicatedMergeTree.cpp:5228: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl[abi:se190107] const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000015f9a5fe 17. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000015ed8bfd 18. /build/src/Storages/StorageReplicatedMergeTree.cpp:2514: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x0000000015ec9aab 19. /build/src/Storages/StorageReplicatedMergeTree.cpp:2349: DB::StorageReplicatedMergeTree::executeLogEntry(DB::ReplicatedMergeTreeLogEntry&) @ 0x0000000015eba91b 20. /build/src/Storages/StorageReplicatedMergeTree.cpp:3876: bool std::__function::__policy_invoker&)>::__call_impl[abi:se190107])::$_1, bool (std::shared_ptr&)>>(std::__function::__policy_storage const*, std::shared_ptr&) @ 0x0000000015f9837e 21. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000165d6fc3 22. /build/src/Storages/StorageReplicatedMergeTree.cpp:3872: DB::StorageReplicatedMergeTree::processQueueEntry(std::shared_ptr) @ 0x0000000015efc18a 23. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001624c1b2 24. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000162f9c70 25. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x00000000162fa55a 26. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc6653 27. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000000fccc4c3 28. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc3d92 29. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fcca080 30. ? @ 0x00007fbc6213eac3 31. ? @ 0x00007fbc621d0850 (version 25.3.6.10636.altinitytest (altinity build)) 2025.07.28 11:53:50.812556 [ 17557 ] {98f238fb-b026-4702-abf9-a739d74f4081} executeQuery: Code: 44. DB::Exception: Cannot create column with type 'Variant(Int32)' because Variant type is not allowed. Set setting enable_variant_type = 1 in order to allow it: In scope SELECT CAST('{}', 'JSON(a Variant(Int32))'). (ILLEGAL_COLUMN) (version 25.3.6.10636.altinitytest (altinity build)) (from [::1]:46738) (comment: 03261_json_hints_types_check.sql) (query 6, line 7) (in query: select '{}'::JSON(a Variant(Int32));), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x000000000a06b56b 4. /build/src/Interpreters/parseColumnsListForTableFunction.cpp:105: DB::validateDataType(std::shared_ptr const&, DB::DataTypeValidationSettings const&)::$_0::operator()(DB::IDataType const&) const @ 0x0000000014cce784 5. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000013bfdcfa 6. /build/src/Interpreters/parseColumnsListForTableFunction.cpp:173: DB::validateDataType(std::shared_ptr const&, DB::DataTypeValidationSettings const&) @ 0x0000000014ccde2d 7. /build/src/Functions/CastOverloadResolver.cpp:128: DB::CastOverloadResolverImpl::getReturnTypeImpl(std::vector> const&) const @ 0x0000000012dcd4a5 8. /build/src/Functions/IFunction.cpp:645: DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x0000000012d96b0c 9. /build/src/Functions/IFunction.cpp:585: DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x0000000012d9665b 10. /build/src/Functions/IFunction.cpp:606: DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x0000000012d96edc 11. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3544: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000014033cc9 12. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3838: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000014019a9e 13. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3980: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000014018e31 14. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:4304: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000014042fa7 15. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5605: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000014013749 16. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000140127f9 17. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000014011fce 18. /build/src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000001406ce8a 19. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000014973b42 20. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000001497268d 21. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000014974d24 22. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001492924b 23. /build/src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88641 24. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 25. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 26. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 27. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 28. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 29. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 30. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 31. ? @ 0x00007fbc6213eac3 2025.07.28 11:53:50.816733 [ 17557 ] {} TCPHandler: Code: 44. DB::Exception: Cannot create column with type 'Variant(Int32)' because Variant type is not allowed. Set setting enable_variant_type = 1 in order to allow it: In scope SELECT CAST('{}', 'JSON(a Variant(Int32))'). (ILLEGAL_COLUMN), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x000000000a06b56b 4. /build/src/Interpreters/parseColumnsListForTableFunction.cpp:105: DB::validateDataType(std::shared_ptr const&, DB::DataTypeValidationSettings const&)::$_0::operator()(DB::IDataType const&) const @ 0x0000000014cce784 5. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000013bfdcfa 6. /build/src/Interpreters/parseColumnsListForTableFunction.cpp:173: DB::validateDataType(std::shared_ptr const&, DB::DataTypeValidationSettings const&) @ 0x0000000014ccde2d 7. /build/src/Functions/CastOverloadResolver.cpp:128: DB::CastOverloadResolverImpl::getReturnTypeImpl(std::vector> const&) const @ 0x0000000012dcd4a5 8. /build/src/Functions/IFunction.cpp:645: DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x0000000012d96b0c 9. /build/src/Functions/IFunction.cpp:585: DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x0000000012d9665b 10. /build/src/Functions/IFunction.cpp:606: DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x0000000012d96edc 11. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3544: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000014033cc9 12. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3838: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000014019a9e 13. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3980: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000014018e31 14. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:4304: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000014042fa7 15. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5605: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000014013749 16. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000140127f9 17. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000014011fce 18. /build/src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000001406ce8a 19. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000014973b42 20. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000001497268d 21. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000014974d24 22. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001492924b 23. /build/src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88641 24. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 25. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 26. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 27. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 28. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 29. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 30. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 31. ? @ 0x00007fbc6213eac3 2025.07.28 11:53:50.982099 [ 17557 ] {df7c2520-772d-495e-859d-6ceb1871e644} 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('{}', 'JSON(a Object(\'json\'))'). (ILLEGAL_COLUMN) (version 25.3.6.10636.altinitytest (altinity build)) (from [::1]:46738) (comment: 03261_json_hints_types_check.sql) (query 7, line 8) (in query: select '{}'::JSON(a Object('json'));), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x000000000a06b56b 4. /build/src/Interpreters/parseColumnsListForTableFunction.cpp:79: DB::validateDataType(std::shared_ptr const&, DB::DataTypeValidationSettings const&)::$_0::operator()(DB::IDataType const&) const @ 0x0000000014cce6ec 5. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000013bfdcfa 6. /build/src/Interpreters/parseColumnsListForTableFunction.cpp:173: DB::validateDataType(std::shared_ptr const&, DB::DataTypeValidationSettings const&) @ 0x0000000014ccde2d 7. /build/src/Functions/CastOverloadResolver.cpp:128: DB::CastOverloadResolverImpl::getReturnTypeImpl(std::vector> const&) const @ 0x0000000012dcd4a5 8. /build/src/Functions/IFunction.cpp:645: DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x0000000012d96b0c 9. /build/src/Functions/IFunction.cpp:585: DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x0000000012d9665b 10. /build/src/Functions/IFunction.cpp:606: DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x0000000012d96edc 11. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3544: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000014033cc9 12. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3838: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000014019a9e 13. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3980: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000014018e31 14. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:4304: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000014042fa7 15. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5605: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000014013749 16. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000140127f9 17. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000014011fce 18. /build/src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000001406ce8a 19. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000014973b42 20. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000001497268d 21. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000014974d24 22. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001492924b 23. /build/src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88641 24. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 25. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 26. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 27. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 28. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 29. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 30. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 31. ? @ 0x00007fbc6213eac3 2025.07.28 11:53:51.003620 [ 17557 ] {} 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('{}', 'JSON(a Object(\'json\'))'). (ILLEGAL_COLUMN), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x000000000a06b56b 4. /build/src/Interpreters/parseColumnsListForTableFunction.cpp:79: DB::validateDataType(std::shared_ptr const&, DB::DataTypeValidationSettings const&)::$_0::operator()(DB::IDataType const&) const @ 0x0000000014cce6ec 5. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000013bfdcfa 6. /build/src/Interpreters/parseColumnsListForTableFunction.cpp:173: DB::validateDataType(std::shared_ptr const&, DB::DataTypeValidationSettings const&) @ 0x0000000014ccde2d 7. /build/src/Functions/CastOverloadResolver.cpp:128: DB::CastOverloadResolverImpl::getReturnTypeImpl(std::vector> const&) const @ 0x0000000012dcd4a5 8. /build/src/Functions/IFunction.cpp:645: DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x0000000012d96b0c 9. /build/src/Functions/IFunction.cpp:585: DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x0000000012d9665b 10. /build/src/Functions/IFunction.cpp:606: DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x0000000012d96edc 11. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3544: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000014033cc9 12. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3838: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000014019a9e 13. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3980: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000014018e31 14. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:4304: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000014042fa7 15. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5605: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000014013749 16. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000140127f9 17. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000014011fce 18. /build/src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000001406ce8a 19. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000014973b42 20. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000001497268d 21. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000014974d24 22. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001492924b 23. /build/src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88641 24. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 25. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 26. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 27. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 28. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 29. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 30. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 31. ? @ 0x00007fbc6213eac3 2025.07.28 11:53:51.481382 [ 17252 ] {aca8f0a5-110d-4fb8-8fbb-6e8b1c7d35e7} executeQuery: Code: 42. DB::Exception: Number of arguments for function toMillisecond doesn't match: passed 0, should be 1 or 2: In scope SELECT toMillisecond(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.6.10636.altinitytest (altinity build)) (from [::1]:60176) (comment: 02998_to_milliseconds.sql) (query 1, line 1) (in query: -- Negative tests SELECT toMillisecond();), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, unsigned long&&) @ 0x000000000a06f86b 4. /build/src/Functions/IFunctionDateOrDateTime.h:68: DB::FunctionDateOrDateTimeBase::checkArguments(std::vector> const&, bool) const @ 0x000000000e81e3b6 5. /build/src/Functions/FunctionDateOrDateTimeToSomething.h:23: DB::FunctionDateOrDateTimeToSomething, DB::ToMillisecondImpl>::getReturnTypeImpl(std::vector> const&) const @ 0x000000000e85acc8 6. /build/src/Functions/IFunction.cpp:645: DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x0000000012d96b0c 7. /build/src/Functions/IFunction.cpp:577: DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x0000000012d9669c 8. /build/src/Functions/IFunction.cpp:606: DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x0000000012d96edc 9. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3544: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000014033cc9 10. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3838: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000014019a9e 11. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3980: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000014018e31 12. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:4304: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000014042fa7 13. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5605: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000014013749 14. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000140127f9 15. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000014011fce 16. /build/src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000001406ce8a 17. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000014973b42 18. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000001497268d 19. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000014974d24 20. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001492924b 21. /build/src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88641 22. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 23. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 24. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 25. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 26. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 27. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 28. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 29. ? @ 0x00007fbc6213eac3 30. ? @ 0x00007fbc621d0850 2025.07.28 11:53:51.523447 [ 17252 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function toMillisecond doesn't match: passed 0, should be 1 or 2: In scope SELECT toMillisecond(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, unsigned long&&) @ 0x000000000a06f86b 4. /build/src/Functions/IFunctionDateOrDateTime.h:68: DB::FunctionDateOrDateTimeBase::checkArguments(std::vector> const&, bool) const @ 0x000000000e81e3b6 5. /build/src/Functions/FunctionDateOrDateTimeToSomething.h:23: DB::FunctionDateOrDateTimeToSomething, DB::ToMillisecondImpl>::getReturnTypeImpl(std::vector> const&) const @ 0x000000000e85acc8 6. /build/src/Functions/IFunction.cpp:645: DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x0000000012d96b0c 7. /build/src/Functions/IFunction.cpp:577: DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x0000000012d9669c 8. /build/src/Functions/IFunction.cpp:606: DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x0000000012d96edc 9. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3544: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000014033cc9 10. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3838: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000014019a9e 11. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3980: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000014018e31 12. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:4304: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000014042fa7 13. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5605: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000014013749 14. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000140127f9 15. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000014011fce 16. /build/src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000001406ce8a 17. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000014973b42 18. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000001497268d 19. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000014974d24 20. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001492924b 21. /build/src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88641 22. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 23. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 24. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 25. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 26. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 27. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 28. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 29. ? @ 0x00007fbc6213eac3 30. ? @ 0x00007fbc621d0850 2025.07.28 11:53:51.642779 [ 3960 ] {} test_13.rmt2 (7f9b740d-015c-470e-8cc6-8ba33be0dc63): auto DB::StorageReplicatedMergeTree::processQueueEntry(ReplicatedMergeTreeQueue::SelectedEntryPtr)::(anonymous class)::operator()(LogEntryPtr &) const: Code: 86. DB::HTTPException: Received error from remote server http://146b4357c08d:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Ftest%2F01165%2Ftest_13%2Frmt%2Freplicas%2F1&part=20250728_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.6.10636.altinitytest (altinity build)) '. (RECEIVED_ERROR_FROM_REMOTE_IO_SERVER), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.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 const&, int&&, String const&, unsigned long&&, String const&) @ 0x000000000feda8d9 4. /build/src/IO/HTTPCommon.cpp:104: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x000000000feda6e2 5. /build/src/IO/HTTPCommon.cpp:93: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x000000000feda537 6. /build/src/IO/ReadWriteBufferFromHTTP.cpp:277: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x000000001184a4c4 7. /build/src/IO/ReadWriteBufferFromHTTP.cpp:285: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x000000001184a615 8. /build/src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x000000001184ae59 9. /build/src/IO/ReadWriteBufferFromHTTP.cpp:472: void std::__function::__policy_invoker::__call_impl[abi:se190107]>(std::__function::__policy_storage const*) @ 0x000000001184cedd 10. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001184858b 11. /build/src/IO/ReadWriteBufferFromHTTP.cpp:465: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x000000001184bf0b 12. /build/src/IO/ReadBuffer.h:60: DB::ReadBuffer::next() @ 0x000000000a148c7b 13. /build/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) @ 0x0000000011849fb2 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]>&)>&, 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&) @ 0x0000000011841980 15. /build/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) @ 0x000000001621208e 16. /build/src/Storages/StorageReplicatedMergeTree.cpp:5228: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl[abi:se190107] const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000015f9a5fe 17. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000015ed8bfd 18. /build/src/Storages/StorageReplicatedMergeTree.cpp:2514: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x0000000015ec9aab 19. /build/src/Storages/StorageReplicatedMergeTree.cpp:2349: DB::StorageReplicatedMergeTree::executeLogEntry(DB::ReplicatedMergeTreeLogEntry&) @ 0x0000000015eba91b 20. /build/src/Storages/StorageReplicatedMergeTree.cpp:3876: bool std::__function::__policy_invoker&)>::__call_impl[abi:se190107])::$_1, bool (std::shared_ptr&)>>(std::__function::__policy_storage const*, std::shared_ptr&) @ 0x0000000015f9837e 21. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000165d6fc3 22. /build/src/Storages/StorageReplicatedMergeTree.cpp:3872: DB::StorageReplicatedMergeTree::processQueueEntry(std::shared_ptr) @ 0x0000000015efc18a 23. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001624c1b2 24. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000162f9c70 25. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x00000000162fa55a 26. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc6653 27. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000000fccc4c3 28. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc3d92 29. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fcca080 30. ? @ 0x00007fbc6213eac3 31. ? @ 0x00007fbc621d0850 (version 25.3.6.10636.altinitytest (altinity build)) 2025.07.28 11:53:51.737942 [ 17252 ] {8f359890-a4f4-45db-a638-b70cf3a0aa62} executeQuery: Code: 43. DB::Exception: Illegal type String of argument of function toMillisecond. Should be Date, Date32, DateTime or DateTime64: In scope SELECT toMillisecond('string'). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.6.10636.altinitytest (altinity build)) (from [::1]:60176) (comment: 02998_to_milliseconds.sql) (query 2, line 3) (in query: SELECT toMillisecond('string');), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000a06a8eb 4. /build/src/Functions/IFunctionDateOrDateTime.h:47: DB::FunctionDateOrDateTimeBase::checkArguments(std::vector> const&, bool) const @ 0x000000000e81e274 5. /build/src/Functions/FunctionDateOrDateTimeToSomething.h:23: DB::FunctionDateOrDateTimeToSomething, DB::ToMillisecondImpl>::getReturnTypeImpl(std::vector> const&) const @ 0x000000000e85acc8 6. /build/src/Functions/IFunction.cpp:645: DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x0000000012d96b0c 7. /build/src/Functions/IFunction.cpp:577: DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x0000000012d9669c 8. /build/src/Functions/IFunction.cpp:606: DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x0000000012d96edc 9. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3544: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000014033cc9 10. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3838: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000014019a9e 11. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3980: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000014018e31 12. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:4304: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000014042fa7 13. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5605: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000014013749 14. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000140127f9 15. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000014011fce 16. /build/src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000001406ce8a 17. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000014973b42 18. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000001497268d 19. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000014974d24 20. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001492924b 21. /build/src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88641 22. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 23. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 24. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 25. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 26. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 27. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 28. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 29. ? @ 0x00007fbc6213eac3 30. ? @ 0x00007fbc621d0850 2025.07.28 11:53:51.772705 [ 17252 ] {} TCPHandler: Code: 43. DB::Exception: Illegal type String of argument of function toMillisecond. Should be Date, Date32, DateTime or DateTime64: In scope SELECT toMillisecond('string'). (ILLEGAL_TYPE_OF_ARGUMENT), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000a06a8eb 4. /build/src/Functions/IFunctionDateOrDateTime.h:47: DB::FunctionDateOrDateTimeBase::checkArguments(std::vector> const&, bool) const @ 0x000000000e81e274 5. /build/src/Functions/FunctionDateOrDateTimeToSomething.h:23: DB::FunctionDateOrDateTimeToSomething, DB::ToMillisecondImpl>::getReturnTypeImpl(std::vector> const&) const @ 0x000000000e85acc8 6. /build/src/Functions/IFunction.cpp:645: DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x0000000012d96b0c 7. /build/src/Functions/IFunction.cpp:577: DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x0000000012d9669c 8. /build/src/Functions/IFunction.cpp:606: DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x0000000012d96edc 9. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3544: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000014033cc9 10. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3838: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000014019a9e 11. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3980: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000014018e31 12. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:4304: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000014042fa7 13. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5605: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000014013749 14. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000140127f9 15. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000014011fce 16. /build/src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000001406ce8a 17. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000014973b42 18. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000001497268d 19. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000014974d24 20. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001492924b 21. /build/src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88641 22. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 23. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 24. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 25. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 26. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 27. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 28. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 29. ? @ 0x00007fbc6213eac3 30. ? @ 0x00007fbc621d0850 2025.07.28 11:53:51.919356 [ 17191 ] {} 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. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x000000000c25bc4b 4. /build/src/Access/SettingsConstraints.cpp:343: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000138596e3 5. /build/src/Access/SettingsConstraints.cpp:300: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000013858faf 6. /build/src/Access/SettingsConstraints.cpp:209: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x00000000138592b8 7. /build/src/Interpreters/Context.cpp:2690: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000014436134 8. /build/src/Interpreters/Context.cpp:2729: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x000000001443662b 9. /build/src/Server/TCPHandler.cpp:2158: DB::TCPHandler::processQuery(std::optional&) @ 0x00000000168f61df 10. /build/src/Server/TCPHandler.cpp:918: DB::TCPHandler::receivePacketsExpectQuery(std::optional&) @ 0x00000000168ef965 11. /build/src/Server/TCPHandler.cpp:491: DB::TCPHandler::runImpl() @ 0x00000000168e5eb4 12. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 13. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 14. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 16. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 17. ? @ 0x00007fbc6213eac3 18. ? @ 0x00007fbc621d0850 2025.07.28 11:53:51.923989 [ 17191 ] {} 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. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000000a074fcb 4. /build/src/Server/TCPHandler.cpp:897: DB::TCPHandler::receivePacketsExpectQuery(std::optional&) @ 0x00000000168efa89 5. /build/src/Server/TCPHandler.cpp:491: DB::TCPHandler::runImpl() @ 0x00000000168e5eb4 6. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 7. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 8. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 9. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 10. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 11. ? @ 0x00007fbc6213eac3 12. ? @ 0x00007fbc621d0850 2025.07.28 11:53:52.012906 [ 17252 ] {5ef1a6ab-2d0f-4f60-964d-9a13ca7ea27c} executeQuery: Code: 43. DB::Exception: Illegal argument of type Date for function toMillisecond: In scope SELECT toMillisecond(toDate('2024-02-28')). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.6.10636.altinitytest (altinity build)) (from [::1]:60176) (comment: 02998_to_milliseconds.sql) (query 3, line 4) (in query: SELECT toMillisecond(toDate('2024-02-28'));), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type>, char const*&) @ 0x000000000a06d8cb 4. /build/src/Functions/DateTimeTransforms.cpp:13: DB::throwDateIsNotSupported(char const*) @ 0x000000000a06d705 5. /build/src/Functions/DateTimeTransforms.h:1599: COW::immutable_ptr DB::DateTimeTransformImpl, DB::ToMillisecondImpl, false>::execute(std::vector> const&, std::shared_ptr const&, unsigned long, DB::ToMillisecondImpl const&) @ 0x000000000e85af1e 6. /build/src/Functions/FunctionDateOrDateTimeToSomething.h:72: DB::FunctionDateOrDateTimeToSomething, DB::ToMillisecondImpl>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000e85a9a0 7. /build/src/Functions/IFunction.h:437: DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000a069f2a 8. /build/src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000012d9965a 9. /build/src/Functions/IFunction.cpp:351: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d93b02 10. /build/src/Functions/IFunction.cpp:177: DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d93698 11. /build/src/Functions/IFunction.cpp:343: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d93aad 12. /build/src/Functions/IFunction.cpp:420: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d95059 13. /build/src/Functions/IFunction.cpp:498: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d95c72 14. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3567: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000014034494 15. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3838: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000014019a9e 16. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3980: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000014018e31 17. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:4304: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000014042fa7 18. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5605: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000014013749 19. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000140127f9 20. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000014011fce 21. /build/src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000001406ce8a 22. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000014973b42 23. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000001497268d 24. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000014974d24 25. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001492924b 26. /build/src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88641 27. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 28. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 29. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 30. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 31. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 2025.07.28 11:53:52.030495 [ 17252 ] {} TCPHandler: Code: 43. DB::Exception: Illegal argument of type Date for function toMillisecond: In scope SELECT toMillisecond(toDate('2024-02-28')). (ILLEGAL_TYPE_OF_ARGUMENT), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type>, char const*&) @ 0x000000000a06d8cb 4. /build/src/Functions/DateTimeTransforms.cpp:13: DB::throwDateIsNotSupported(char const*) @ 0x000000000a06d705 5. /build/src/Functions/DateTimeTransforms.h:1599: COW::immutable_ptr DB::DateTimeTransformImpl, DB::ToMillisecondImpl, false>::execute(std::vector> const&, std::shared_ptr const&, unsigned long, DB::ToMillisecondImpl const&) @ 0x000000000e85af1e 6. /build/src/Functions/FunctionDateOrDateTimeToSomething.h:72: DB::FunctionDateOrDateTimeToSomething, DB::ToMillisecondImpl>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000e85a9a0 7. /build/src/Functions/IFunction.h:437: DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000a069f2a 8. /build/src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000012d9965a 9. /build/src/Functions/IFunction.cpp:351: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d93b02 10. /build/src/Functions/IFunction.cpp:177: DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d93698 11. /build/src/Functions/IFunction.cpp:343: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d93aad 12. /build/src/Functions/IFunction.cpp:420: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d95059 13. /build/src/Functions/IFunction.cpp:498: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d95c72 14. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3567: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000014034494 15. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3838: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000014019a9e 16. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3980: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000014018e31 17. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:4304: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000014042fa7 18. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5605: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000014013749 19. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000140127f9 20. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000014011fce 21. /build/src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000001406ce8a 22. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000014973b42 23. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000001497268d 24. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000014974d24 25. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001492924b 26. /build/src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88641 27. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 28. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 29. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 30. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 31. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 2025.07.28 11:53:52.090978 [ 17207 ] {} SettingsSanity: Sanity check: 'max_block_size' cannot be 0. Set to default value 65409 2025.07.28 11:53:52.193510 [ 17252 ] {df632785-8110-40a0-8552-cb6d2bcbdde5} executeQuery: Code: 43. DB::Exception: Illegal argument of type Date32 for function toMillisecond: In scope SELECT toMillisecond(toDate32('2024-02-28')). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.6.10636.altinitytest (altinity build)) (from [::1]:60176) (comment: 02998_to_milliseconds.sql) (query 4, line 5) (in query: SELECT toMillisecond(toDate32('2024-02-28'));), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type>, char const*&) @ 0x000000000a06d8cb 4. /build/src/Functions/DateTimeTransforms.cpp:18: DB::throwDate32IsNotSupported(char const*) @ 0x000000000a06d7a5 5. /build/src/Functions/DateTimeTransforms.h:1595: COW::immutable_ptr DB::DateTimeTransformImpl, DB::ToMillisecondImpl, false>::execute(std::vector> const&, std::shared_ptr const&, unsigned long, DB::ToMillisecondImpl const&) @ 0x000000000e85b1fe 6. /build/src/Functions/FunctionDateOrDateTimeToSomething.h:74: DB::FunctionDateOrDateTimeToSomething, DB::ToMillisecondImpl>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000e85a9cd 7. /build/src/Functions/IFunction.h:437: DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000a069f2a 8. /build/src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000012d9965a 9. /build/src/Functions/IFunction.cpp:351: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d93b02 10. /build/src/Functions/IFunction.cpp:177: DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d93698 11. /build/src/Functions/IFunction.cpp:343: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d93aad 12. /build/src/Functions/IFunction.cpp:420: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d95059 13. /build/src/Functions/IFunction.cpp:498: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d95c72 14. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3567: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000014034494 15. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3838: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000014019a9e 16. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3980: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000014018e31 17. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:4304: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000014042fa7 18. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5605: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000014013749 19. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000140127f9 20. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000014011fce 21. /build/src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000001406ce8a 22. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000014973b42 23. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000001497268d 24. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000014974d24 25. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001492924b 26. /build/src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88641 27. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 28. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 29. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 30. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 31. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 2025.07.28 11:53:52.197345 [ 17252 ] {} TCPHandler: Code: 43. DB::Exception: Illegal argument of type Date32 for function toMillisecond: In scope SELECT toMillisecond(toDate32('2024-02-28')). (ILLEGAL_TYPE_OF_ARGUMENT), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type>, char const*&) @ 0x000000000a06d8cb 4. /build/src/Functions/DateTimeTransforms.cpp:18: DB::throwDate32IsNotSupported(char const*) @ 0x000000000a06d7a5 5. /build/src/Functions/DateTimeTransforms.h:1595: COW::immutable_ptr DB::DateTimeTransformImpl, DB::ToMillisecondImpl, false>::execute(std::vector> const&, std::shared_ptr const&, unsigned long, DB::ToMillisecondImpl const&) @ 0x000000000e85b1fe 6. /build/src/Functions/FunctionDateOrDateTimeToSomething.h:74: DB::FunctionDateOrDateTimeToSomething, DB::ToMillisecondImpl>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000e85a9cd 7. /build/src/Functions/IFunction.h:437: DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000a069f2a 8. /build/src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000012d9965a 9. /build/src/Functions/IFunction.cpp:351: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d93b02 10. /build/src/Functions/IFunction.cpp:177: DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d93698 11. /build/src/Functions/IFunction.cpp:343: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d93aad 12. /build/src/Functions/IFunction.cpp:420: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d95059 13. /build/src/Functions/IFunction.cpp:498: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d95c72 14. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3567: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000014034494 15. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3838: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000014019a9e 16. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3980: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000014018e31 17. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:4304: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000014042fa7 18. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5605: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000014013749 19. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000140127f9 20. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000014011fce 21. /build/src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000001406ce8a 22. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000014973b42 23. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000001497268d 24. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000014974d24 25. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001492924b 26. /build/src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88641 27. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 28. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 29. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 30. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 31. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 2025.07.28 11:53:52.206649 [ 17207 ] {56ca3593-9b48-4425-bcfe-cb1248af4b0d} SettingsSanity: Sanity check: 'max_block_size' cannot be 0. Set to default value 65409 2025.07.28 11:53:52.228698 [ 17207 ] {56ca3593-9b48-4425-bcfe-cb1248af4b0d} SettingsSanity: Sanity check: 'max_block_size' cannot be 0. Set to default value 65409 2025.07.28 11:53:52.234669 [ 3963 ] {} test_13.rmt2 (7f9b740d-015c-470e-8cc6-8ba33be0dc63): auto DB::StorageReplicatedMergeTree::processQueueEntry(ReplicatedMergeTreeQueue::SelectedEntryPtr)::(anonymous class)::operator()(LogEntryPtr &) const: Code: 86. DB::HTTPException: Received error from remote server http://146b4357c08d:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Ftest%2F01165%2Ftest_13%2Frmt%2Freplicas%2F1&part=20250728_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.6.10636.altinitytest (altinity build)) '. (RECEIVED_ERROR_FROM_REMOTE_IO_SERVER), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.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 const&, int&&, String const&, unsigned long&&, String const&) @ 0x000000000feda8d9 4. /build/src/IO/HTTPCommon.cpp:104: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x000000000feda6e2 5. /build/src/IO/HTTPCommon.cpp:93: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x000000000feda537 6. /build/src/IO/ReadWriteBufferFromHTTP.cpp:277: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x000000001184a4c4 7. /build/src/IO/ReadWriteBufferFromHTTP.cpp:285: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x000000001184a615 8. /build/src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x000000001184ae59 9. /build/src/IO/ReadWriteBufferFromHTTP.cpp:472: void std::__function::__policy_invoker::__call_impl[abi:se190107]>(std::__function::__policy_storage const*) @ 0x000000001184cedd 10. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001184858b 11. /build/src/IO/ReadWriteBufferFromHTTP.cpp:465: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x000000001184bf0b 12. /build/src/IO/ReadBuffer.h:60: DB::ReadBuffer::next() @ 0x000000000a148c7b 13. /build/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) @ 0x0000000011849fb2 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]>&)>&, 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&) @ 0x0000000011841980 15. /build/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) @ 0x000000001621208e 16. /build/src/Storages/StorageReplicatedMergeTree.cpp:5228: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl[abi:se190107] const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000015f9a5fe 17. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000015ed8bfd 18. /build/src/Storages/StorageReplicatedMergeTree.cpp:2514: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x0000000015ec9aab 19. /build/src/Storages/StorageReplicatedMergeTree.cpp:2349: DB::StorageReplicatedMergeTree::executeLogEntry(DB::ReplicatedMergeTreeLogEntry&) @ 0x0000000015eba91b 20. /build/src/Storages/StorageReplicatedMergeTree.cpp:3876: bool std::__function::__policy_invoker&)>::__call_impl[abi:se190107])::$_1, bool (std::shared_ptr&)>>(std::__function::__policy_storage const*, std::shared_ptr&) @ 0x0000000015f9837e 21. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000165d6fc3 22. /build/src/Storages/StorageReplicatedMergeTree.cpp:3872: DB::StorageReplicatedMergeTree::processQueueEntry(std::shared_ptr) @ 0x0000000015efc18a 23. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001624c1b2 24. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000162f9c70 25. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x00000000162fa55a 26. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc6653 27. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000000fccc4c3 28. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc3d92 29. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fcca080 30. ? @ 0x00007fbc6213eac3 31. ? @ 0x00007fbc621d0850 (version 25.3.6.10636.altinitytest (altinity build)) 2025.07.28 11:53:52.417570 [ 4581 ] {acf6ff12-62da-42f5-8a64-5e377274df78} executeQuery: Code: 153. DB::Exception: Division by zero: while executing 'FUNCTION modulo(1_UInt8 :: 1, modulo(plus(__table1.number, 500_UInt16), 1000_UInt16) :: 2) -> modulo(1_UInt8, modulo(plus(__table1.number, 500_UInt16), 1000_UInt16)) UInt16 : 3'. (ILLEGAL_DIVISION) (version 25.3.6.10636.altinitytest (altinity build)) (from [::1]:46668) (comment: 00093_union_race_conditions_4.sh) (query 1, line 1) (in query: SELECT 1 % ((number + 500) % 1000) FROM numbers_mt(1000);), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000000a074fcb 4. /build/src/Functions/DivisionUtils.h:26: void DB::impl_::BinaryOperation, unsigned short>::process<(DB::impl_::OpCase)1>(char8_t const*, unsigned short const*, unsigned short*, unsigned long, DB::PODArray, 63ul, 64ul> const*) @ 0x000000000d184621 5. /build/src/Functions/FunctionBinaryArithmetic.h:2338: COW::immutable_ptr DB::FunctionBinaryArithmetic::executeNumeric, DB::DataTypeNumber>(std::vector> const&, DB::DataTypeNumber const&, DB::DataTypeNumber const&, DB::PODArray, 63ul, 64ul> const*) const @ 0x000000000d3a6416 6. /build/src/Functions/FunctionBinaryArithmetic.h:2508: 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&&) @ 0x000000000d3a4a68 7. /build/src/Functions/FunctionBinaryArithmetic.h:846: 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&&) @ 0x000000000d3a3ec7 8. /build/src/Functions/FunctionBinaryArithmetic.h:844: DB::FunctionBinaryArithmetic::executeImpl2(std::vector> const&, std::shared_ptr const&, unsigned long, DB::PODArray, 63ul, 64ul> const*) const @ 0x000000000d3a03c5 9. /build/src/Functions/FunctionBinaryArithmetic.h:2410: DB::FunctionBinaryArithmetic::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000d39e94c 10. /build/src/Functions/FunctionBinaryArithmetic.h:2645: DB::FunctionBinaryArithmeticWithConstants::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000d39dbd4 11. /build/src/Functions/IFunctionAdaptors.cpp:10: DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000012d995fa 12. /build/src/Functions/IFunction.cpp:353: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d93b52 13. /build/src/Functions/IFunction.cpp:420: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d95059 14. /build/src/Functions/IFunction.cpp:498: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d95c72 15. /build/src/Interpreters/ExpressionActions.cpp:636: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x00000000145176f3 16. /build/src/Processors/Transforms/ExpressionTransform.cpp:25: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x0000000016c0b34c 17. /build/src/Processors/ISimpleTransform.h:33: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000011a9a453 18. /build/src/Processors/ISimpleTransform.cpp:89: DB::ISimpleTransform::work() @ 0x000000001699fca0 19. /build/src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x00000000169bd00f 20. /build/src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x00000000169b2105 21. /build/src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeSingleThread(unsigned long) @ 0x00000000169b23be 22. /build/src/Processors/Executors/PipelineExecutor.cpp:454: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x00000000169b0be7 23. /build/src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x00000000169b03f4 24. /build/src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:se190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169bfeab 25. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc3d92 26. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fcca080 27. ? @ 0x00007fbc6213eac3 28. ? @ 0x00007fbc621d0850 2025.07.28 11:53:52.450410 [ 4581 ] {} TCPHandler: Code: 153. DB::Exception: Division by zero: while executing 'FUNCTION modulo(1_UInt8 :: 1, modulo(plus(__table1.number, 500_UInt16), 1000_UInt16) :: 2) -> modulo(1_UInt8, modulo(plus(__table1.number, 500_UInt16), 1000_UInt16)) UInt16 : 3'. (ILLEGAL_DIVISION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000000a074fcb 4. /build/src/Functions/DivisionUtils.h:26: void DB::impl_::BinaryOperation, unsigned short>::process<(DB::impl_::OpCase)1>(char8_t const*, unsigned short const*, unsigned short*, unsigned long, DB::PODArray, 63ul, 64ul> const*) @ 0x000000000d184621 5. /build/src/Functions/FunctionBinaryArithmetic.h:2338: COW::immutable_ptr DB::FunctionBinaryArithmetic::executeNumeric, DB::DataTypeNumber>(std::vector> const&, DB::DataTypeNumber const&, DB::DataTypeNumber const&, DB::PODArray, 63ul, 64ul> const*) const @ 0x000000000d3a6416 6. /build/src/Functions/FunctionBinaryArithmetic.h:2508: 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&&) @ 0x000000000d3a4a68 7. /build/src/Functions/FunctionBinaryArithmetic.h:846: 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&&) @ 0x000000000d3a3ec7 8. /build/src/Functions/FunctionBinaryArithmetic.h:844: DB::FunctionBinaryArithmetic::executeImpl2(std::vector> const&, std::shared_ptr const&, unsigned long, DB::PODArray, 63ul, 64ul> const*) const @ 0x000000000d3a03c5 9. /build/src/Functions/FunctionBinaryArithmetic.h:2410: DB::FunctionBinaryArithmetic::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000d39e94c 10. /build/src/Functions/FunctionBinaryArithmetic.h:2645: DB::FunctionBinaryArithmeticWithConstants::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000d39dbd4 11. /build/src/Functions/IFunctionAdaptors.cpp:10: DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000012d995fa 12. /build/src/Functions/IFunction.cpp:353: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d93b52 13. /build/src/Functions/IFunction.cpp:420: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d95059 14. /build/src/Functions/IFunction.cpp:498: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d95c72 15. /build/src/Interpreters/ExpressionActions.cpp:636: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x00000000145176f3 16. /build/src/Processors/Transforms/ExpressionTransform.cpp:25: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x0000000016c0b34c 17. /build/src/Processors/ISimpleTransform.h:33: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000011a9a453 18. /build/src/Processors/ISimpleTransform.cpp:89: DB::ISimpleTransform::work() @ 0x000000001699fca0 19. /build/src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x00000000169bd00f 20. /build/src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x00000000169b2105 21. /build/src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeSingleThread(unsigned long) @ 0x00000000169b23be 22. /build/src/Processors/Executors/PipelineExecutor.cpp:454: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x00000000169b0be7 23. /build/src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x00000000169b03f4 24. /build/src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:se190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169bfeab 25. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc3d92 26. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fcca080 27. ? @ 0x00007fbc6213eac3 28. ? @ 0x00007fbc621d0850 Job's origin stack trace: 0. /build/src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000000fc33b84 1. /build/src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000000fcc2ea7 2. /build/src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fcc535c 3. /build/src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000000fcc584d 4. /build/src/Common/ThreadPool.h:279: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x00000000169bf193 5. /build/src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x00000000169bf518 6. /build/src/Server/TCPHandler.cpp:1237: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x00000000168f1525 7. /build/src/Server/TCPHandler.cpp:678: DB::TCPHandler::runImpl() @ 0x00000000168e68e5 8. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 9. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 10. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 11. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 12. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 13. ? @ 0x00007fbc6213eac3 14. ? @ 0x00007fbc621d0850 2025.07.28 11:53:52.733891 [ 3968 ] {} test_13.rmt2 (7f9b740d-015c-470e-8cc6-8ba33be0dc63): auto DB::StorageReplicatedMergeTree::processQueueEntry(ReplicatedMergeTreeQueue::SelectedEntryPtr)::(anonymous class)::operator()(LogEntryPtr &) const: Code: 86. DB::HTTPException: Received error from remote server http://146b4357c08d:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Ftest%2F01165%2Ftest_13%2Frmt%2Freplicas%2F1&part=20250728_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.6.10636.altinitytest (altinity build)) '. (RECEIVED_ERROR_FROM_REMOTE_IO_SERVER), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.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 const&, int&&, String const&, unsigned long&&, String const&) @ 0x000000000feda8d9 4. /build/src/IO/HTTPCommon.cpp:104: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x000000000feda6e2 5. /build/src/IO/HTTPCommon.cpp:93: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x000000000feda537 6. /build/src/IO/ReadWriteBufferFromHTTP.cpp:277: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x000000001184a4c4 7. /build/src/IO/ReadWriteBufferFromHTTP.cpp:285: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x000000001184a615 8. /build/src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x000000001184ae59 9. /build/src/IO/ReadWriteBufferFromHTTP.cpp:472: void std::__function::__policy_invoker::__call_impl[abi:se190107]>(std::__function::__policy_storage const*) @ 0x000000001184cedd 10. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001184858b 11. /build/src/IO/ReadWriteBufferFromHTTP.cpp:465: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x000000001184bf0b 12. /build/src/IO/ReadBuffer.h:60: DB::ReadBuffer::next() @ 0x000000000a148c7b 13. /build/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) @ 0x0000000011849fb2 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]>&)>&, 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&) @ 0x0000000011841980 15. /build/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) @ 0x000000001621208e 16. /build/src/Storages/StorageReplicatedMergeTree.cpp:5228: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl[abi:se190107] const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000015f9a5fe 17. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000015ed8bfd 18. /build/src/Storages/StorageReplicatedMergeTree.cpp:2514: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x0000000015ec9aab 19. /build/src/Storages/StorageReplicatedMergeTree.cpp:2349: DB::StorageReplicatedMergeTree::executeLogEntry(DB::ReplicatedMergeTreeLogEntry&) @ 0x0000000015eba91b 20. /build/src/Storages/StorageReplicatedMergeTree.cpp:3876: bool std::__function::__policy_invoker&)>::__call_impl[abi:se190107])::$_1, bool (std::shared_ptr&)>>(std::__function::__policy_storage const*, std::shared_ptr&) @ 0x0000000015f9837e 21. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000165d6fc3 22. /build/src/Storages/StorageReplicatedMergeTree.cpp:3872: DB::StorageReplicatedMergeTree::processQueueEntry(std::shared_ptr) @ 0x0000000015efc18a 23. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001624c1b2 24. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000162f9c70 25. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x00000000162fa55a 26. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc6653 27. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000000fccc4c3 28. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc3d92 29. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fcca080 30. ? @ 0x00007fbc6213eac3 31. ? @ 0x00007fbc621d0850 (version 25.3.6.10636.altinitytest (altinity build)) 2025.07.28 11:53:52.835507 [ 4900 ] {} 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. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception>&, String>(int, FormatStringHelperImpl>&>::type, std::type_identity::type>, std::basic_string_view>&, String&&) @ 0x000000001385a5eb 4. /build/src/Access/SettingsConstraints.cpp:376: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000013859b18 5. /build/src/Access/SettingsConstraints.cpp:300: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000013858faf 6. /build/src/Access/SettingsConstraints.cpp:209: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000013859223 7. /build/src/Interpreters/Context.cpp:2690: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000014436134 8. /build/src/Interpreters/Context.cpp:2729: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x000000001443662b 9. /build/src/Server/HTTPHandler.cpp:457: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000001686d165 10. /build/src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x0000000016870807 11. /build/src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x0000000016907e99 12. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 13. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 14. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 15. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 16. ? @ 0x00007fbc6213eac3 17. ? @ 0x00007fbc621d0850 (version 25.3.6.10636.altinitytest (altinity build)) 2025.07.28 11:53:53.277525 [ 17371 ] {d55f1f1a-df75-42ff-ab7a-8dfa1c07a839} executeQuery: Code: 47. DB::Exception: Missing columns: 'test_01103.t1_distr.id' while processing: '_CAST(now(([NULL, NULL, NULL, [-2147483648], [NULL, NULL, NULL, NULL, NULL, NULL, NULL]] AND (1048576 AND NULL) AND (NULL AND 1048575 AND NULL AND -2147483649) AND NULL) IN (test_01103.t1_distr.id)) AS b_tmp_alter15307402293615445263, 'DateTime') AS b, b_tmp_alter15307402293615445263', required columns: 'test_01103.t1_distr.id', available columns: 'b' 'a': default expression and column type are incompatible. (UNKNOWN_IDENTIFIER) (version 25.3.6.10636.altinitytest (altinity build)) (from [::1]:60298) (comment: 02041_test_fuzzy_alter.sql) (query 3, line 7) (in query: ALTER TABLE alter_table MODIFY COLUMN `b` DateTime DEFAULT now(([NULL, NULL, NULL, [-2147483648], [NULL, NULL, NULL, NULL, NULL, NULL, NULL]] AND (1048576 AND NULL) AND (NULL AND 1048575 AND NULL AND -2147483649) AND NULL) IN (test_01103.t1_distr.id));), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Interpreters/TreeRewriter.cpp:1303: DB::TreeRewriterResult::collectUsedColumns(std::shared_ptr const&, bool, bool) @ 0x0000000014c01fc8 4. /build/src/Interpreters/TreeRewriter.cpp:1561: DB::TreeRewriter::analyze(std::shared_ptr&, DB::NamesAndTypesList const&, std::shared_ptr, std::shared_ptr const&, bool, bool, bool, bool) const @ 0x0000000014c0a438 5. /build/src/Storages/ColumnsDescription.cpp:1017: DB::(anonymous namespace)::validateColumnsDefaultsAndGetSampleBlockImpl(std::shared_ptr, DB::NamesAndTypesList const&, std::shared_ptr, bool) @ 0x0000000015d07a0e 6. /build/src/Storages/ColumnsDescription.cpp:1044: DB::validateColumnsDefaultsAndGetSampleBlock(std::shared_ptr, DB::NamesAndTypesList const&, std::shared_ptr) @ 0x0000000015d07ee6 7. /build/src/Storages/AlterCommands.cpp:1762: DB::AlterCommands::validate(std::shared_ptr const&, std::shared_ptr) const @ 0x0000000015cf6298 8. /build/src/Interpreters/InterpreterAlterQuery.cpp:213: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x00000000148dea74 9. /build/src/Interpreters/InterpreterAlterQuery.cpp:77: DB::InterpreterAlterQuery::execute() @ 0x00000000148dcb0d 10. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88dc9 11. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 12. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 13. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 14. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 15. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 16. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 17. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 18. ? @ 0x00007fbc6213eac3 19. ? @ 0x00007fbc621d0850 2025.07.28 11:53:53.289469 [ 17371 ] {} TCPHandler: Code: 47. DB::Exception: Missing columns: 'test_01103.t1_distr.id' while processing: '_CAST(now(([NULL, NULL, NULL, [-2147483648], [NULL, NULL, NULL, NULL, NULL, NULL, NULL]] AND (1048576 AND NULL) AND (NULL AND 1048575 AND NULL AND -2147483649) AND NULL) IN (test_01103.t1_distr.id)) AS b_tmp_alter15307402293615445263, 'DateTime') AS b, b_tmp_alter15307402293615445263', required columns: 'test_01103.t1_distr.id', available columns: 'b' 'a': default expression and column type are incompatible. (UNKNOWN_IDENTIFIER), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Interpreters/TreeRewriter.cpp:1303: DB::TreeRewriterResult::collectUsedColumns(std::shared_ptr const&, bool, bool) @ 0x0000000014c01fc8 4. /build/src/Interpreters/TreeRewriter.cpp:1561: DB::TreeRewriter::analyze(std::shared_ptr&, DB::NamesAndTypesList const&, std::shared_ptr, std::shared_ptr const&, bool, bool, bool, bool) const @ 0x0000000014c0a438 5. /build/src/Storages/ColumnsDescription.cpp:1017: DB::(anonymous namespace)::validateColumnsDefaultsAndGetSampleBlockImpl(std::shared_ptr, DB::NamesAndTypesList const&, std::shared_ptr, bool) @ 0x0000000015d07a0e 6. /build/src/Storages/ColumnsDescription.cpp:1044: DB::validateColumnsDefaultsAndGetSampleBlock(std::shared_ptr, DB::NamesAndTypesList const&, std::shared_ptr) @ 0x0000000015d07ee6 7. /build/src/Storages/AlterCommands.cpp:1762: DB::AlterCommands::validate(std::shared_ptr const&, std::shared_ptr) const @ 0x0000000015cf6298 8. /build/src/Interpreters/InterpreterAlterQuery.cpp:213: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x00000000148dea74 9. /build/src/Interpreters/InterpreterAlterQuery.cpp:77: DB::InterpreterAlterQuery::execute() @ 0x00000000148dcb0d 10. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88dc9 11. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 12. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 13. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 14. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 15. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 16. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 17. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 18. ? @ 0x00007fbc6213eac3 19. ? @ 0x00007fbc621d0850 2025.07.28 11:53:53.298509 [ 3972 ] {} test_13.rmt2 (7f9b740d-015c-470e-8cc6-8ba33be0dc63): auto DB::StorageReplicatedMergeTree::processQueueEntry(ReplicatedMergeTreeQueue::SelectedEntryPtr)::(anonymous class)::operator()(LogEntryPtr &) const: Code: 86. DB::HTTPException: Received error from remote server http://146b4357c08d:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Ftest%2F01165%2Ftest_13%2Frmt%2Freplicas%2F1&part=20250728_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.6.10636.altinitytest (altinity build)) '. (RECEIVED_ERROR_FROM_REMOTE_IO_SERVER), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.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 const&, int&&, String const&, unsigned long&&, String const&) @ 0x000000000feda8d9 4. /build/src/IO/HTTPCommon.cpp:104: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x000000000feda6e2 5. /build/src/IO/HTTPCommon.cpp:93: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x000000000feda537 6. /build/src/IO/ReadWriteBufferFromHTTP.cpp:277: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x000000001184a4c4 7. /build/src/IO/ReadWriteBufferFromHTTP.cpp:285: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x000000001184a615 8. /build/src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x000000001184ae59 9. /build/src/IO/ReadWriteBufferFromHTTP.cpp:472: void std::__function::__policy_invoker::__call_impl[abi:se190107]>(std::__function::__policy_storage const*) @ 0x000000001184cedd 10. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001184858b 11. /build/src/IO/ReadWriteBufferFromHTTP.cpp:465: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x000000001184bf0b 12. /build/src/IO/ReadBuffer.h:60: DB::ReadBuffer::next() @ 0x000000000a148c7b 13. /build/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) @ 0x0000000011849fb2 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]>&)>&, 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&) @ 0x0000000011841980 15. /build/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) @ 0x000000001621208e 16. /build/src/Storages/StorageReplicatedMergeTree.cpp:5228: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl[abi:se190107] const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000015f9a5fe 17. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000015ed8bfd 18. /build/src/Storages/StorageReplicatedMergeTree.cpp:2514: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x0000000015ec9aab 19. /build/src/Storages/StorageReplicatedMergeTree.cpp:2349: DB::StorageReplicatedMergeTree::executeLogEntry(DB::ReplicatedMergeTreeLogEntry&) @ 0x0000000015eba91b 20. /build/src/Storages/StorageReplicatedMergeTree.cpp:3876: bool std::__function::__policy_invoker&)>::__call_impl[abi:se190107])::$_1, bool (std::shared_ptr&)>>(std::__function::__policy_storage const*, std::shared_ptr&) @ 0x0000000015f9837e 21. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000165d6fc3 22. /build/src/Storages/StorageReplicatedMergeTree.cpp:3872: DB::StorageReplicatedMergeTree::processQueueEntry(std::shared_ptr) @ 0x0000000015efc18a 23. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001624c1b2 24. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000162f9c70 25. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x00000000162fa55a 26. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc6653 27. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000000fccc4c3 28. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc3d92 29. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fcca080 30. ? @ 0x00007fbc6213eac3 31. ? @ 0x00007fbc621d0850 (version 25.3.6.10636.altinitytest (altinity build)) 2025.07.28 11:53:53.620309 [ 5879 ] {7be5c4fd-3de1-4607-812d-3f08becb2f8e} executeQuery: Code: 100. DB::Exception: Unknown packet 9223372036854775807 from server 127.0.0.2:9000: While executing Remote. (UNKNOWN_PACKET_FROM_SERVER) (version 25.3.6.10636.altinitytest (altinity build)) (from [::1]:60314) (comment: 01822_async_read_from_socket_crash.sh) (query 1, line 1) (in query: select number from remote('127.0.0.{2,3}', numbers(20)) limit 8 settings max_block_size = 2, unknown_packet_in_send_data=4, sleep_in_send_data_ms=100, async_socket_for_remote=1 format Null), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String const&) @ 0x000000000a68756b 4. /build/src/Client/Connection.cpp:1323: DB::Connection::receivePacket() @ 0x00000000167db7d2 5. /build/src/Client/PacketReceiver.cpp:66: DB::PacketReceiver::Task::run(std::function, std::function) @ 0x0000000016819393 6. /build/src/Common/AsyncTaskExecutor.cpp:89: DB::AsyncTaskExecutor::Routine::operator()(std::function) @ 0x0000000013bd1892 7. /build/src/Common/Fiber.h:76: boost::context::detail::fiber_record>::run(void*) @ 0x0000000013bd16fa 8. /build/contrib/boost/boost/context/fiber_fcontext.hpp:97: void boost::context::detail::fiber_entry>>(boost::context::detail::transfer_t) @ 0x0000000013bd1621 2025.07.28 11:53:53.654912 [ 5879 ] {} TCPHandler: Code: 100. DB::Exception: Unknown packet 9223372036854775807 from server 127.0.0.2:9000: While executing Remote. (UNKNOWN_PACKET_FROM_SERVER), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String const&) @ 0x000000000a68756b 4. /build/src/Client/Connection.cpp:1323: DB::Connection::receivePacket() @ 0x00000000167db7d2 5. /build/src/Client/PacketReceiver.cpp:66: DB::PacketReceiver::Task::run(std::function, std::function) @ 0x0000000016819393 6. /build/src/Common/AsyncTaskExecutor.cpp:89: DB::AsyncTaskExecutor::Routine::operator()(std::function) @ 0x0000000013bd1892 7. /build/src/Common/Fiber.h:76: boost::context::detail::fiber_record>::run(void*) @ 0x0000000013bd16fa 8. /build/contrib/boost/boost/context/fiber_fcontext.hpp:97: void boost::context::detail::fiber_entry>>(boost::context::detail::transfer_t) @ 0x0000000013bd1621 Job's origin stack trace: 0. /build/src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000000fc33b84 1. /build/src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000000fcc2ea7 2. /build/src/Common/ThreadPool.cpp:401: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fcc7f1c 3. /build/src/Common/ThreadPool.cpp:494: ThreadPoolImpl>::scheduleOrThrowOnError(std::function, Priority) @ 0x000000000fcc7a0e 4. /build/src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::spawnThreadsImpl() @ 0x00000000169b2c0c 5. /build/src/Processors/Executors/PipelineExecutor.cpp:394: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x00000000169b0ba7 6. /build/src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x00000000169b03f4 7. /build/src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:se190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169bfeab 8. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc3d92 9. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fcca080 10. ? @ 0x00007fbc6213eac3 11. ? @ 0x00007fbc621d0850 Job's origin stack trace: 0. /build/src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000000fc33b84 1. /build/src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000000fcc2ea7 2. /build/src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fcc535c 3. /build/src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000000fcc584d 4. /build/src/Common/ThreadPool.h:279: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x00000000169bf193 5. /build/src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x00000000169bf518 6. /build/src/Server/TCPHandler.cpp:1237: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x00000000168f1525 7. /build/src/Server/TCPHandler.cpp:678: DB::TCPHandler::runImpl() @ 0x00000000168e68e5 8. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 9. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 10. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 11. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 12. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 13. ? @ 0x00007fbc6213eac3 14. ? @ 0x00007fbc621d0850 2025.07.28 11:53:53.676372 [ 3971 ] {} test_13.rmt2 (7f9b740d-015c-470e-8cc6-8ba33be0dc63): auto DB::StorageReplicatedMergeTree::processQueueEntry(ReplicatedMergeTreeQueue::SelectedEntryPtr)::(anonymous class)::operator()(LogEntryPtr &) const: Code: 86. DB::HTTPException: Received error from remote server http://146b4357c08d:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Ftest%2F01165%2Ftest_13%2Frmt%2Freplicas%2F1&part=20250728_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.6.10636.altinitytest (altinity build)) '. (RECEIVED_ERROR_FROM_REMOTE_IO_SERVER), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.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 const&, int&&, String const&, unsigned long&&, String const&) @ 0x000000000feda8d9 4. /build/src/IO/HTTPCommon.cpp:104: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x000000000feda6e2 5. /build/src/IO/HTTPCommon.cpp:93: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x000000000feda537 6. /build/src/IO/ReadWriteBufferFromHTTP.cpp:277: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x000000001184a4c4 7. /build/src/IO/ReadWriteBufferFromHTTP.cpp:285: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x000000001184a615 8. /build/src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x000000001184ae59 9. /build/src/IO/ReadWriteBufferFromHTTP.cpp:472: void std::__function::__policy_invoker::__call_impl[abi:se190107]>(std::__function::__policy_storage const*) @ 0x000000001184cedd 10. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001184858b 11. /build/src/IO/ReadWriteBufferFromHTTP.cpp:465: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x000000001184bf0b 12. /build/src/IO/ReadBuffer.h:60: DB::ReadBuffer::next() @ 0x000000000a148c7b 13. /build/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) @ 0x0000000011849fb2 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]>&)>&, 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&) @ 0x0000000011841980 15. /build/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) @ 0x000000001621208e 16. /build/src/Storages/StorageReplicatedMergeTree.cpp:5228: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl[abi:se190107] const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000015f9a5fe 17. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000015ed8bfd 18. /build/src/Storages/StorageReplicatedMergeTree.cpp:2514: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x0000000015ec9aab 19. /build/src/Storages/StorageReplicatedMergeTree.cpp:2349: DB::StorageReplicatedMergeTree::executeLogEntry(DB::ReplicatedMergeTreeLogEntry&) @ 0x0000000015eba91b 20. /build/src/Storages/StorageReplicatedMergeTree.cpp:3876: bool std::__function::__policy_invoker&)>::__call_impl[abi:se190107])::$_1, bool (std::shared_ptr&)>>(std::__function::__policy_storage const*, std::shared_ptr&) @ 0x0000000015f9837e 21. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000165d6fc3 22. /build/src/Storages/StorageReplicatedMergeTree.cpp:3872: DB::StorageReplicatedMergeTree::processQueueEntry(std::shared_ptr) @ 0x0000000015efc18a 23. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001624c1b2 24. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000162f9c70 25. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x00000000162fa55a 26. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc6653 27. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000000fccc4c3 28. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc3d92 29. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fcca080 30. ? @ 0x00007fbc6213eac3 31. ? @ 0x00007fbc621d0850 (version 25.3.6.10636.altinitytest (altinity build)) 2025.07.28 11:53:53.693237 [ 17207 ] {81db922c-8da7-481d-83e1-48fcd139f21c} executeQuery: Code: 236. DB::NetException: Client has dropped the connection, cancel the query. (ABORTED) (version 25.3.6.10636.altinitytest (altinity build)) (from [::ffff:127.0.0.1]:41000) (comment: 01822_async_read_from_socket_crash.sh) (query 1, line 1) (in query: SELECT `__table1`.`number` AS `number` FROM numbers(20) AS `__table1` LIMIT _CAST(8, 'UInt64')), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::NetException::NetException(int, T&&) @ 0x0000000016900f80 3. /build/src/Server/TCPHandler.cpp:2426: DB::TCPHandler::receivePacketsExpectCancel(DB::QueryState&) @ 0x00000000168fba18 4. /build/src/Server/TCPHandler.cpp:1242: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x00000000168f1540 5. /build/src/Server/TCPHandler.cpp:678: DB::TCPHandler::runImpl() @ 0x00000000168e68e5 6. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 7. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 8. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 9. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 10. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 11. ? @ 0x00007fbc6213eac3 12. ? @ 0x00007fbc621d0850 2025.07.28 11:53:53.767414 [ 11826 ] {d6e181f6-4868-476f-80c4-2611d22264fe} 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]:59958). (NETWORK_ERROR), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::NetException::NetException(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&) @ 0x000000000fd50fb5 3. /build/src/IO/WriteBufferFromPocoSocket.cpp:171: DB::WriteBufferFromPocoSocket::nextImpl() @ 0x000000000fd525a7 4. /build/src/IO/WriteBuffer.h:53: DB::WriteBuffer::next() @ 0x000000000a0755be 5. /build/src/Server/TCPHandler.cpp:824: DB::TCPHandler::runImpl() @ 0x00000000168e6c86 6. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 7. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 8. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 9. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 10. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 11. ? @ 0x00007fbc6213eac3 12. ? @ 0x00007fbc621d0850 (version 25.3.6.10636.altinitytest (altinity build)) 2025.07.28 11:53:53.780580 [ 17207 ] {81db922c-8da7-481d-83e1-48fcd139f21c} 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]:41000). (NETWORK_ERROR), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::NetException::NetException(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&) @ 0x000000000fd50fb5 3. /build/src/IO/WriteBufferFromPocoSocket.cpp:171: DB::WriteBufferFromPocoSocket::nextImpl() @ 0x000000000fd525a7 4. /build/src/IO/WriteBuffer.h:53: DB::WriteBuffer::next() @ 0x000000000a0755be 5. /build/src/Server/TCPHandler.cpp:2620: DB::TCPHandler::sendLogs(DB::QueryState&) @ 0x00000000168f1e17 6. /build/src/Server/TCPHandler.cpp:821: DB::TCPHandler::runImpl() @ 0x00000000168e6c63 7. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 8. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 9. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 10. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 11. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 12. ? @ 0x00007fbc6213eac3 13. ? @ 0x00007fbc621d0850 (version 25.3.6.10636.altinitytest (altinity build)) 2025.07.28 11:53:53.822540 [ 17207 ] {} 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. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::NetException::NetException(int, T&&) @ 0x0000000016900f80 3. /build/src/Server/TCPHandler.cpp:2426: DB::TCPHandler::receivePacketsExpectCancel(DB::QueryState&) @ 0x00000000168fba18 4. /build/src/Server/TCPHandler.cpp:1242: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x00000000168f1540 5. /build/src/Server/TCPHandler.cpp:678: DB::TCPHandler::runImpl() @ 0x00000000168e68e5 6. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 7. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 8. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 9. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 10. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 11. ? @ 0x00007fbc6213eac3 12. ? @ 0x00007fbc621d0850 2025.07.28 11:53:54.334549 [ 3976 ] {} test_13.rmt2 (7f9b740d-015c-470e-8cc6-8ba33be0dc63): auto DB::StorageReplicatedMergeTree::processQueueEntry(ReplicatedMergeTreeQueue::SelectedEntryPtr)::(anonymous class)::operator()(LogEntryPtr &) const: Code: 86. DB::HTTPException: Received error from remote server http://146b4357c08d:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Ftest%2F01165%2Ftest_13%2Frmt%2Freplicas%2F1&part=20250728_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.6.10636.altinitytest (altinity build)) '. (RECEIVED_ERROR_FROM_REMOTE_IO_SERVER), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.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 const&, int&&, String const&, unsigned long&&, String const&) @ 0x000000000feda8d9 4. /build/src/IO/HTTPCommon.cpp:104: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x000000000feda6e2 5. /build/src/IO/HTTPCommon.cpp:93: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x000000000feda537 6. /build/src/IO/ReadWriteBufferFromHTTP.cpp:277: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x000000001184a4c4 7. /build/src/IO/ReadWriteBufferFromHTTP.cpp:285: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x000000001184a615 8. /build/src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x000000001184ae59 9. /build/src/IO/ReadWriteBufferFromHTTP.cpp:472: void std::__function::__policy_invoker::__call_impl[abi:se190107]>(std::__function::__policy_storage const*) @ 0x000000001184cedd 10. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001184858b 11. /build/src/IO/ReadWriteBufferFromHTTP.cpp:465: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x000000001184bf0b 12. /build/src/IO/ReadBuffer.h:60: DB::ReadBuffer::next() @ 0x000000000a148c7b 13. /build/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) @ 0x0000000011849fb2 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]>&)>&, 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&) @ 0x0000000011841980 15. /build/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) @ 0x000000001621208e 16. /build/src/Storages/StorageReplicatedMergeTree.cpp:5228: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl[abi:se190107] const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000015f9a5fe 17. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000015ed8bfd 18. /build/src/Storages/StorageReplicatedMergeTree.cpp:2514: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x0000000015ec9aab 19. /build/src/Storages/StorageReplicatedMergeTree.cpp:2349: DB::StorageReplicatedMergeTree::executeLogEntry(DB::ReplicatedMergeTreeLogEntry&) @ 0x0000000015eba91b 20. /build/src/Storages/StorageReplicatedMergeTree.cpp:3876: bool std::__function::__policy_invoker&)>::__call_impl[abi:se190107])::$_1, bool (std::shared_ptr&)>>(std::__function::__policy_storage const*, std::shared_ptr&) @ 0x0000000015f9837e 21. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000165d6fc3 22. /build/src/Storages/StorageReplicatedMergeTree.cpp:3872: DB::StorageReplicatedMergeTree::processQueueEntry(std::shared_ptr) @ 0x0000000015efc18a 23. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001624c1b2 24. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000162f9c70 25. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x00000000162fa55a 26. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc6653 27. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000000fccc4c3 28. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc3d92 29. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fcca080 30. ? @ 0x00007fbc6213eac3 31. ? @ 0x00007fbc621d0850 (version 25.3.6.10636.altinitytest (altinity build)) 2025.07.28 11:53:54.439108 [ 5879 ] {0903a67b-f562-4d24-8a7f-a89dca08115e} executeQuery: Code: 100. DB::Exception: Unknown packet 9223372036854775807 from server 127.0.0.2:9000: While executing Remote. (UNKNOWN_PACKET_FROM_SERVER) (version 25.3.6.10636.altinitytest (altinity build)) (from [::1]:60336) (comment: 01822_async_read_from_socket_crash.sh) (query 1, line 1) (in query: select number from remote('127.0.0.{2,3}', numbers(20)) limit 8 settings max_block_size = 2, unknown_packet_in_send_data=4, sleep_in_send_data_ms=100, async_socket_for_remote=1 format Null), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String const&) @ 0x000000000a68756b 4. /build/src/Client/Connection.cpp:1323: DB::Connection::receivePacket() @ 0x00000000167db7d2 5. /build/src/Client/PacketReceiver.cpp:66: DB::PacketReceiver::Task::run(std::function, std::function) @ 0x0000000016819393 6. /build/src/Common/AsyncTaskExecutor.cpp:89: DB::AsyncTaskExecutor::Routine::operator()(std::function) @ 0x0000000013bd1892 7. /build/src/Common/Fiber.h:76: boost::context::detail::fiber_record>::run(void*) @ 0x0000000013bd16fa 8. /build/contrib/boost/boost/context/fiber_fcontext.hpp:97: void boost::context::detail::fiber_entry>>(boost::context::detail::transfer_t) @ 0x0000000013bd1621 2025.07.28 11:53:54.508903 [ 11826 ] {34274923-2818-4d59-ab9f-4b039d6bdab2} executeQuery: Code: 236. DB::NetException: Client has dropped the connection, cancel the query. (ABORTED) (version 25.3.6.10636.altinitytest (altinity build)) (from [::ffff:127.0.0.1]:41002) (comment: 01822_async_read_from_socket_crash.sh) (query 1, line 1) (in query: SELECT `__table1`.`number` AS `number` FROM numbers(20) AS `__table1` LIMIT _CAST(8, 'UInt64')), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::NetException::NetException(int, T&&) @ 0x0000000016900f80 3. /build/src/Server/TCPHandler.cpp:2426: DB::TCPHandler::receivePacketsExpectCancel(DB::QueryState&) @ 0x00000000168fba18 4. /build/src/Server/TCPHandler.cpp:1242: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x00000000168f1540 5. /build/src/Server/TCPHandler.cpp:678: DB::TCPHandler::runImpl() @ 0x00000000168e68e5 6. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 7. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 8. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 9. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 10. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 11. ? @ 0x00007fbc6213eac3 12. ? @ 0x00007fbc621d0850 2025.07.28 11:53:54.514367 [ 11826 ] {34274923-2818-4d59-ab9f-4b039d6bdab2} 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]:41002). (NETWORK_ERROR), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::NetException::NetException(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&) @ 0x000000000fd50fb5 3. /build/src/IO/WriteBufferFromPocoSocket.cpp:171: DB::WriteBufferFromPocoSocket::nextImpl() @ 0x000000000fd525a7 4. /build/src/IO/WriteBuffer.h:53: DB::WriteBuffer::next() @ 0x000000000a0755be 5. /build/src/Server/TCPHandler.cpp:2620: DB::TCPHandler::sendLogs(DB::QueryState&) @ 0x00000000168f1e17 6. /build/src/Server/TCPHandler.cpp:821: DB::TCPHandler::runImpl() @ 0x00000000168e6c63 7. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 8. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 9. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 10. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 11. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 12. ? @ 0x00007fbc6213eac3 13. ? @ 0x00007fbc621d0850 (version 25.3.6.10636.altinitytest (altinity build)) 2025.07.28 11:53:54.515557 [ 5879 ] {} TCPHandler: Code: 100. DB::Exception: Unknown packet 9223372036854775807 from server 127.0.0.2:9000: While executing Remote. (UNKNOWN_PACKET_FROM_SERVER), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String const&) @ 0x000000000a68756b 4. /build/src/Client/Connection.cpp:1323: DB::Connection::receivePacket() @ 0x00000000167db7d2 5. /build/src/Client/PacketReceiver.cpp:66: DB::PacketReceiver::Task::run(std::function, std::function) @ 0x0000000016819393 6. /build/src/Common/AsyncTaskExecutor.cpp:89: DB::AsyncTaskExecutor::Routine::operator()(std::function) @ 0x0000000013bd1892 7. /build/src/Common/Fiber.h:76: boost::context::detail::fiber_record>::run(void*) @ 0x0000000013bd16fa 8. /build/contrib/boost/boost/context/fiber_fcontext.hpp:97: void boost::context::detail::fiber_entry>>(boost::context::detail::transfer_t) @ 0x0000000013bd1621 Job's origin stack trace: 0. /build/src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000000fc33b84 1. /build/src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000000fcc2ea7 2. /build/src/Common/ThreadPool.cpp:401: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fcc7f1c 3. /build/src/Common/ThreadPool.cpp:494: ThreadPoolImpl>::scheduleOrThrowOnError(std::function, Priority) @ 0x000000000fcc7a0e 4. /build/src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::spawnThreadsImpl() @ 0x00000000169b2c0c 5. /build/src/Processors/Executors/PipelineExecutor.cpp:394: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x00000000169b0ba7 6. /build/src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x00000000169b03f4 7. /build/src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:se190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169bfeab 8. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc3d92 9. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fcca080 10. ? @ 0x00007fbc6213eac3 11. ? @ 0x00007fbc621d0850 Job's origin stack trace: 0. /build/src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000000fc33b84 1. /build/src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000000fcc2ea7 2. /build/src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fcc535c 3. /build/src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000000fcc584d 4. /build/src/Common/ThreadPool.h:279: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x00000000169bf193 5. /build/src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x00000000169bf518 6. /build/src/Server/TCPHandler.cpp:1237: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x00000000168f1525 7. /build/src/Server/TCPHandler.cpp:678: DB::TCPHandler::runImpl() @ 0x00000000168e68e5 8. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 9. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 10. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 11. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 12. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 13. ? @ 0x00007fbc6213eac3 14. ? @ 0x00007fbc621d0850 2025.07.28 11:53:54.518359 [ 11826 ] {} 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. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::NetException::NetException(int, T&&) @ 0x0000000016900f80 3. /build/src/Server/TCPHandler.cpp:2426: DB::TCPHandler::receivePacketsExpectCancel(DB::QueryState&) @ 0x00000000168fba18 4. /build/src/Server/TCPHandler.cpp:1242: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x00000000168f1540 5. /build/src/Server/TCPHandler.cpp:678: DB::TCPHandler::runImpl() @ 0x00000000168e68e5 6. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 7. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 8. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 9. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 10. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 11. ? @ 0x00007fbc6213eac3 12. ? @ 0x00007fbc621d0850 2025.07.28 11:53:54.528357 [ 17207 ] {470206df-c622-4210-97a1-a0eac4c38159} 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]:59968). (NETWORK_ERROR), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::NetException::NetException(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&) @ 0x000000000fd50fb5 3. /build/src/IO/WriteBufferFromPocoSocket.cpp:160: DB::WriteBufferFromPocoSocket::nextImpl() @ 0x000000000fd523f1 4. /build/src/IO/WriteBuffer.h:53: DB::WriteBuffer::next() @ 0x000000000a0755be 5. /build/src/Server/TCPHandler.cpp:2490: DB::TCPHandler::sendData(DB::QueryState&, DB::Block const&) @ 0x00000000168fa306 6. /build/src/Server/TCPHandler.cpp:1266: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x00000000168f162c 7. /build/src/Server/TCPHandler.cpp:678: DB::TCPHandler::runImpl() @ 0x00000000168e68e5 8. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 9. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 10. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 11. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 12. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 13. ? @ 0x00007fbc6213eac3 14. ? @ 0x00007fbc621d0850 (version 25.3.6.10636.altinitytest (altinity build)) 2025.07.28 11:53:54.531237 [ 17207 ] {470206df-c622-4210-97a1-a0eac4c38159} executeQuery: Code: 210. DB::NetException: Connection reset by peer, while writing to socket ([::ffff:127.0.0.3]:9000 -> [::ffff:127.0.0.1]:59968). (NETWORK_ERROR) (version 25.3.6.10636.altinitytest (altinity build)) (from [::ffff:127.0.0.1]:59968) (comment: 01822_async_read_from_socket_crash.sh) (query 1, line 1) (in query: SELECT `__table1`.`number` AS `number` FROM numbers(20) AS `__table1` LIMIT _CAST(8, 'UInt64')), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::NetException::NetException(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&) @ 0x000000000fd50fb5 3. /build/src/IO/WriteBufferFromPocoSocket.cpp:160: DB::WriteBufferFromPocoSocket::nextImpl() @ 0x000000000fd523f1 4. /build/src/IO/WriteBuffer.h:53: DB::WriteBuffer::next() @ 0x000000000a0755be 5. /build/src/Server/TCPHandler.cpp:2490: DB::TCPHandler::sendData(DB::QueryState&, DB::Block const&) @ 0x00000000168fa306 6. /build/src/Server/TCPHandler.cpp:1266: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x00000000168f162c 7. /build/src/Server/TCPHandler.cpp:678: DB::TCPHandler::runImpl() @ 0x00000000168e68e5 8. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 9. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 10. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 11. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 12. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 13. ? @ 0x00007fbc6213eac3 14. ? @ 0x00007fbc621d0850 2025.07.28 11:53:54.542015 [ 17207 ] {} TCPHandler: Code: 210. DB::NetException: Connection reset by peer, while writing to socket ([::ffff:127.0.0.3]:9000 -> [::ffff:127.0.0.1]:59968). (NETWORK_ERROR), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::NetException::NetException(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&) @ 0x000000000fd50fb5 3. /build/src/IO/WriteBufferFromPocoSocket.cpp:160: DB::WriteBufferFromPocoSocket::nextImpl() @ 0x000000000fd523f1 4. /build/src/IO/WriteBuffer.h:53: DB::WriteBuffer::next() @ 0x000000000a0755be 5. /build/src/Server/TCPHandler.cpp:2490: DB::TCPHandler::sendData(DB::QueryState&, DB::Block const&) @ 0x00000000168fa306 6. /build/src/Server/TCPHandler.cpp:1266: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x00000000168f162c 7. /build/src/Server/TCPHandler.cpp:678: DB::TCPHandler::runImpl() @ 0x00000000168e68e5 8. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 9. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 10. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 11. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 12. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 13. ? @ 0x00007fbc6213eac3 14. ? @ 0x00007fbc621d0850 2025.07.28 11:53:55.151734 [ 17371 ] {738e24a8-d2e8-449c-96a9-fb86e268d4c7} executeQuery: Code: 420. DB::Exception: Cannot update column `d` with type Dynamic: updates of columns with dynamic subcolumns are not supported. (CANNOT_UPDATE_COLUMN) (version 25.3.6.10636.altinitytest (altinity build)) (from 0.0.0.0:0) (comment: 03226_alter_update_dynamic_json_not_supported.sql) (in query: /* ddl_entry=query-0000000003 */ ALTER TABLE test_8kn8txev.test (UPDATE d = 42 WHERE 1)), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000a06a8eb 4. /build/src/Interpreters/MutationsInterpreter.cpp:1426: DB::MutationsInterpreter::validate() @ 0x0000000014a31b94 5. /build/src/Interpreters/InterpreterAlterQuery.cpp:235: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x00000000148deddb 6. /build/src/Interpreters/InterpreterAlterQuery.cpp:77: DB::InterpreterAlterQuery::execute() @ 0x00000000148dcb0d 7. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88dc9 8. /build/src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x0000000014c8ca7b 9. /build/src/Interpreters/DDLWorker.cpp:510: DB::DDLWorker::tryExecuteQuery(DB::DDLTaskBase&, std::shared_ptr const&, bool) @ 0x00000000144dab9e 10. /build/src/Interpreters/DDLWorker.cpp:675: DB::DDLWorker::processTask(DB::DDLTaskBase&, std::shared_ptr const&, bool) @ 0x00000000144d8ffe 11. /build/src/Databases/DatabaseReplicatedWorker.cpp:372: DB::DatabaseReplicatedDDLWorker::tryEnqueueAndExecuteEntry(DB::DDLLogEntry&, std::shared_ptr, bool) @ 0x0000000013dc29ab 12. /build/src/Databases/DatabaseReplicated.cpp:1139: DB::DatabaseReplicated::tryEnqueueReplicatedDDL(std::shared_ptr const&, std::shared_ptr, DB::QueryFlags) @ 0x0000000013d9f73c 13. /build/src/Interpreters/InterpreterAlterQuery.cpp:130: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x00000000148dd805 14. /build/src/Interpreters/InterpreterAlterQuery.cpp:77: DB::InterpreterAlterQuery::execute() @ 0x00000000148dcb0d 15. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88dc9 16. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 17. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 18. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 19. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 20. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 21. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 22. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 23. ? @ 0x00007fbc6213eac3 24. ? @ 0x00007fbc621d0850 2025.07.28 11:53:55.248875 [ 17371 ] {738e24a8-d2e8-449c-96a9-fb86e268d4c7} executeQuery: Code: 420. DB::Exception: Cannot update column `d` with type Dynamic: updates of columns with dynamic subcolumns are not supported. (CANNOT_UPDATE_COLUMN) (version 25.3.6.10636.altinitytest (altinity build)) (from [::1]:60344) (comment: 03226_alter_update_dynamic_json_not_supported.sql) (query 5, line 6) (in query: alter table test update d = 42 where 1;), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000a06a8eb 4. /build/src/Interpreters/MutationsInterpreter.cpp:1426: DB::MutationsInterpreter::validate() @ 0x0000000014a31b94 5. /build/src/Interpreters/InterpreterAlterQuery.cpp:235: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x00000000148deddb 6. /build/src/Interpreters/InterpreterAlterQuery.cpp:77: DB::InterpreterAlterQuery::execute() @ 0x00000000148dcb0d 7. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88dc9 8. /build/src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x0000000014c8ca7b 9. /build/src/Interpreters/DDLWorker.cpp:510: DB::DDLWorker::tryExecuteQuery(DB::DDLTaskBase&, std::shared_ptr const&, bool) @ 0x00000000144dab9e 10. /build/src/Interpreters/DDLWorker.cpp:675: DB::DDLWorker::processTask(DB::DDLTaskBase&, std::shared_ptr const&, bool) @ 0x00000000144d8ffe 11. /build/src/Databases/DatabaseReplicatedWorker.cpp:372: DB::DatabaseReplicatedDDLWorker::tryEnqueueAndExecuteEntry(DB::DDLLogEntry&, std::shared_ptr, bool) @ 0x0000000013dc29ab 12. /build/src/Databases/DatabaseReplicated.cpp:1139: DB::DatabaseReplicated::tryEnqueueReplicatedDDL(std::shared_ptr const&, std::shared_ptr, DB::QueryFlags) @ 0x0000000013d9f73c 13. /build/src/Interpreters/InterpreterAlterQuery.cpp:130: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x00000000148dd805 14. /build/src/Interpreters/InterpreterAlterQuery.cpp:77: DB::InterpreterAlterQuery::execute() @ 0x00000000148dcb0d 15. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88dc9 16. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 17. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 18. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 19. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 20. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 21. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 22. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 23. ? @ 0x00007fbc6213eac3 24. ? @ 0x00007fbc621d0850 2025.07.28 11:53:55.250671 [ 17371 ] {} TCPHandler: Code: 420. DB::Exception: Cannot update column `d` with type Dynamic: updates of columns with dynamic subcolumns are not supported. (CANNOT_UPDATE_COLUMN), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000a06a8eb 4. /build/src/Interpreters/MutationsInterpreter.cpp:1426: DB::MutationsInterpreter::validate() @ 0x0000000014a31b94 5. /build/src/Interpreters/InterpreterAlterQuery.cpp:235: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x00000000148deddb 6. /build/src/Interpreters/InterpreterAlterQuery.cpp:77: DB::InterpreterAlterQuery::execute() @ 0x00000000148dcb0d 7. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88dc9 8. /build/src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x0000000014c8ca7b 9. /build/src/Interpreters/DDLWorker.cpp:510: DB::DDLWorker::tryExecuteQuery(DB::DDLTaskBase&, std::shared_ptr const&, bool) @ 0x00000000144dab9e 10. /build/src/Interpreters/DDLWorker.cpp:675: DB::DDLWorker::processTask(DB::DDLTaskBase&, std::shared_ptr const&, bool) @ 0x00000000144d8ffe 11. /build/src/Databases/DatabaseReplicatedWorker.cpp:372: DB::DatabaseReplicatedDDLWorker::tryEnqueueAndExecuteEntry(DB::DDLLogEntry&, std::shared_ptr, bool) @ 0x0000000013dc29ab 12. /build/src/Databases/DatabaseReplicated.cpp:1139: DB::DatabaseReplicated::tryEnqueueReplicatedDDL(std::shared_ptr const&, std::shared_ptr, DB::QueryFlags) @ 0x0000000013d9f73c 13. /build/src/Interpreters/InterpreterAlterQuery.cpp:130: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x00000000148dd805 14. /build/src/Interpreters/InterpreterAlterQuery.cpp:77: DB::InterpreterAlterQuery::execute() @ 0x00000000148dcb0d 15. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88dc9 16. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 17. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 18. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 19. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 20. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 21. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 22. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 23. ? @ 0x00007fbc6213eac3 24. ? @ 0x00007fbc621d0850 2025.07.28 11:53:55.304011 [ 3977 ] {} test_13.rmt2 (7f9b740d-015c-470e-8cc6-8ba33be0dc63): auto DB::StorageReplicatedMergeTree::processQueueEntry(ReplicatedMergeTreeQueue::SelectedEntryPtr)::(anonymous class)::operator()(LogEntryPtr &) const: Code: 86. DB::HTTPException: Received error from remote server http://146b4357c08d:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Ftest%2F01165%2Ftest_13%2Frmt%2Freplicas%2F1&part=20250728_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.6.10636.altinitytest (altinity build)) '. (RECEIVED_ERROR_FROM_REMOTE_IO_SERVER), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.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 const&, int&&, String const&, unsigned long&&, String const&) @ 0x000000000feda8d9 4. /build/src/IO/HTTPCommon.cpp:104: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x000000000feda6e2 5. /build/src/IO/HTTPCommon.cpp:93: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x000000000feda537 6. /build/src/IO/ReadWriteBufferFromHTTP.cpp:277: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x000000001184a4c4 7. /build/src/IO/ReadWriteBufferFromHTTP.cpp:285: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x000000001184a615 8. /build/src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x000000001184ae59 9. /build/src/IO/ReadWriteBufferFromHTTP.cpp:472: void std::__function::__policy_invoker::__call_impl[abi:se190107]>(std::__function::__policy_storage const*) @ 0x000000001184cedd 10. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001184858b 11. /build/src/IO/ReadWriteBufferFromHTTP.cpp:465: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x000000001184bf0b 12. /build/src/IO/ReadBuffer.h:60: DB::ReadBuffer::next() @ 0x000000000a148c7b 13. /build/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) @ 0x0000000011849fb2 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]>&)>&, 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&) @ 0x0000000011841980 15. /build/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) @ 0x000000001621208e 16. /build/src/Storages/StorageReplicatedMergeTree.cpp:5228: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl[abi:se190107] const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000015f9a5fe 17. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000015ed8bfd 18. /build/src/Storages/StorageReplicatedMergeTree.cpp:2514: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x0000000015ec9aab 19. /build/src/Storages/StorageReplicatedMergeTree.cpp:2349: DB::StorageReplicatedMergeTree::executeLogEntry(DB::ReplicatedMergeTreeLogEntry&) @ 0x0000000015eba91b 20. /build/src/Storages/StorageReplicatedMergeTree.cpp:3876: bool std::__function::__policy_invoker&)>::__call_impl[abi:se190107])::$_1, bool (std::shared_ptr&)>>(std::__function::__policy_storage const*, std::shared_ptr&) @ 0x0000000015f9837e 21. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000165d6fc3 22. /build/src/Storages/StorageReplicatedMergeTree.cpp:3872: DB::StorageReplicatedMergeTree::processQueueEntry(std::shared_ptr) @ 0x0000000015efc18a 23. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001624c1b2 24. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000162f9c70 25. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x00000000162fa55a 26. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc6653 27. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000000fccc4c3 28. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc3d92 29. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fcca080 30. ? @ 0x00007fbc6213eac3 31. ? @ 0x00007fbc621d0850 (version 25.3.6.10636.altinitytest (altinity build)) 2025.07.28 11:53:55.329758 [ 17207 ] {7565b9b3-2691-414a-a889-af6b3d563b4d} executeQuery: Code: 100. DB::Exception: Unknown packet 9223372036854775807 from server 127.0.0.2:9000: While executing Remote. (UNKNOWN_PACKET_FROM_SERVER) (version 25.3.6.10636.altinitytest (altinity build)) (from [::1]:60356) (comment: 01822_async_read_from_socket_crash.sh) (query 1, line 1) (in query: select number from remote('127.0.0.{2,3}', numbers(20)) limit 8 settings max_block_size = 2, unknown_packet_in_send_data=4, sleep_in_send_data_ms=100, async_socket_for_remote=1 format Null), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String const&) @ 0x000000000a68756b 4. /build/src/Client/Connection.cpp:1323: DB::Connection::receivePacket() @ 0x00000000167db7d2 5. /build/src/Client/PacketReceiver.cpp:66: DB::PacketReceiver::Task::run(std::function, std::function) @ 0x0000000016819393 6. /build/src/Common/AsyncTaskExecutor.cpp:89: DB::AsyncTaskExecutor::Routine::operator()(std::function) @ 0x0000000013bd1892 7. /build/src/Common/Fiber.h:76: boost::context::detail::fiber_record>::run(void*) @ 0x0000000013bd16fa 8. /build/contrib/boost/boost/context/fiber_fcontext.hpp:97: void boost::context::detail::fiber_entry>>(boost::context::detail::transfer_t) @ 0x0000000013bd1621 2025.07.28 11:53:55.356699 [ 17207 ] {} TCPHandler: Code: 100. DB::Exception: Unknown packet 9223372036854775807 from server 127.0.0.2:9000: While executing Remote. (UNKNOWN_PACKET_FROM_SERVER), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String const&) @ 0x000000000a68756b 4. /build/src/Client/Connection.cpp:1323: DB::Connection::receivePacket() @ 0x00000000167db7d2 5. /build/src/Client/PacketReceiver.cpp:66: DB::PacketReceiver::Task::run(std::function, std::function) @ 0x0000000016819393 6. /build/src/Common/AsyncTaskExecutor.cpp:89: DB::AsyncTaskExecutor::Routine::operator()(std::function) @ 0x0000000013bd1892 7. /build/src/Common/Fiber.h:76: boost::context::detail::fiber_record>::run(void*) @ 0x0000000013bd16fa 8. /build/contrib/boost/boost/context/fiber_fcontext.hpp:97: void boost::context::detail::fiber_entry>>(boost::context::detail::transfer_t) @ 0x0000000013bd1621 Job's origin stack trace: 0. /build/src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000000fc33b84 1. /build/src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000000fcc2ea7 2. /build/src/Common/ThreadPool.cpp:401: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fcc7f1c 3. /build/src/Common/ThreadPool.cpp:494: ThreadPoolImpl>::scheduleOrThrowOnError(std::function, Priority) @ 0x000000000fcc7a0e 4. /build/src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::spawnThreadsImpl() @ 0x00000000169b2c0c 5. /build/src/Processors/Executors/PipelineExecutor.cpp:394: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x00000000169b0ba7 6. /build/src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x00000000169b03f4 7. /build/src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:se190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169bfeab 8. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc3d92 9. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fcca080 10. ? @ 0x00007fbc6213eac3 11. ? @ 0x00007fbc621d0850 Job's origin stack trace: 0. /build/src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000000fc33b84 1. /build/src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000000fcc2ea7 2. /build/src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fcc535c 3. /build/src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000000fcc584d 4. /build/src/Common/ThreadPool.h:279: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x00000000169bf193 5. /build/src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x00000000169bf518 6. /build/src/Server/TCPHandler.cpp:1237: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x00000000168f1525 7. /build/src/Server/TCPHandler.cpp:678: DB::TCPHandler::runImpl() @ 0x00000000168e68e5 8. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 9. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 10. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 11. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 12. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 13. ? @ 0x00007fbc6213eac3 14. ? @ 0x00007fbc621d0850 2025.07.28 11:53:55.417921 [ 17203 ] {72557753-f038-4f12-983a-b105c43445ab} executeQuery: Code: 236. DB::NetException: Client has dropped the connection, cancel the query. (ABORTED) (version 25.3.6.10636.altinitytest (altinity build)) (from [::ffff:127.0.0.1]:41008) (comment: 01822_async_read_from_socket_crash.sh) (query 1, line 1) (in query: SELECT `__table1`.`number` AS `number` FROM numbers(20) AS `__table1` LIMIT _CAST(8, 'UInt64')), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::NetException::NetException(int, T&&) @ 0x0000000016900f80 3. /build/src/Server/TCPHandler.cpp:2426: DB::TCPHandler::receivePacketsExpectCancel(DB::QueryState&) @ 0x00000000168fba18 4. /build/src/Server/TCPHandler.cpp:1242: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x00000000168f1540 5. /build/src/Server/TCPHandler.cpp:678: DB::TCPHandler::runImpl() @ 0x00000000168e68e5 6. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 7. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 8. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 9. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 10. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 11. ? @ 0x00007fbc6213eac3 12. ? @ 0x00007fbc621d0850 2025.07.28 11:53:55.419995 [ 17203 ] {72557753-f038-4f12-983a-b105c43445ab} 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]:41008). (NETWORK_ERROR), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::NetException::NetException(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&) @ 0x000000000fd50fb5 3. /build/src/IO/WriteBufferFromPocoSocket.cpp:171: DB::WriteBufferFromPocoSocket::nextImpl() @ 0x000000000fd525a7 4. /build/src/IO/WriteBuffer.h:53: DB::WriteBuffer::next() @ 0x000000000a0755be 5. /build/src/Server/TCPHandler.cpp:2620: DB::TCPHandler::sendLogs(DB::QueryState&) @ 0x00000000168f1e17 6. /build/src/Server/TCPHandler.cpp:821: DB::TCPHandler::runImpl() @ 0x00000000168e6c63 7. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 8. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 9. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 10. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 11. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 12. ? @ 0x00007fbc6213eac3 13. ? @ 0x00007fbc621d0850 (version 25.3.6.10636.altinitytest (altinity build)) 2025.07.28 11:53:55.425313 [ 5327 ] {c1dee53e-a1ed-493a-90dd-fa7cbc84858f} 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]:59972). (NETWORK_ERROR), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::NetException::NetException(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&) @ 0x000000000fd50fb5 3. /build/src/IO/WriteBufferFromPocoSocket.cpp:160: DB::WriteBufferFromPocoSocket::nextImpl() @ 0x000000000fd523f1 4. /build/src/IO/WriteBuffer.h:53: DB::WriteBuffer::next() @ 0x000000000a0755be 5. /build/src/Server/TCPHandler.cpp:2490: DB::TCPHandler::sendData(DB::QueryState&, DB::Block const&) @ 0x00000000168fa306 6. /build/src/Server/TCPHandler.cpp:1266: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x00000000168f162c 7. /build/src/Server/TCPHandler.cpp:678: DB::TCPHandler::runImpl() @ 0x00000000168e68e5 8. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 9. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 10. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 11. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 12. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 13. ? @ 0x00007fbc6213eac3 14. ? @ 0x00007fbc621d0850 (version 25.3.6.10636.altinitytest (altinity build)) 2025.07.28 11:53:55.428636 [ 5327 ] {c1dee53e-a1ed-493a-90dd-fa7cbc84858f} executeQuery: Code: 210. DB::NetException: Connection reset by peer, while writing to socket ([::ffff:127.0.0.3]:9000 -> [::ffff:127.0.0.1]:59972). (NETWORK_ERROR) (version 25.3.6.10636.altinitytest (altinity build)) (from [::ffff:127.0.0.1]:59972) (comment: 01822_async_read_from_socket_crash.sh) (query 1, line 1) (in query: SELECT `__table1`.`number` AS `number` FROM numbers(20) AS `__table1` LIMIT _CAST(8, 'UInt64')), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::NetException::NetException(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&) @ 0x000000000fd50fb5 3. /build/src/IO/WriteBufferFromPocoSocket.cpp:160: DB::WriteBufferFromPocoSocket::nextImpl() @ 0x000000000fd523f1 4. /build/src/IO/WriteBuffer.h:53: DB::WriteBuffer::next() @ 0x000000000a0755be 5. /build/src/Server/TCPHandler.cpp:2490: DB::TCPHandler::sendData(DB::QueryState&, DB::Block const&) @ 0x00000000168fa306 6. /build/src/Server/TCPHandler.cpp:1266: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x00000000168f162c 7. /build/src/Server/TCPHandler.cpp:678: DB::TCPHandler::runImpl() @ 0x00000000168e68e5 8. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 9. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 10. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 11. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 12. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 13. ? @ 0x00007fbc6213eac3 14. ? @ 0x00007fbc621d0850 2025.07.28 11:53:55.430292 [ 17203 ] {} 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. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::NetException::NetException(int, T&&) @ 0x0000000016900f80 3. /build/src/Server/TCPHandler.cpp:2426: DB::TCPHandler::receivePacketsExpectCancel(DB::QueryState&) @ 0x00000000168fba18 4. /build/src/Server/TCPHandler.cpp:1242: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x00000000168f1540 5. /build/src/Server/TCPHandler.cpp:678: DB::TCPHandler::runImpl() @ 0x00000000168e68e5 6. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 7. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 8. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 9. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 10. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 11. ? @ 0x00007fbc6213eac3 12. ? @ 0x00007fbc621d0850 2025.07.28 11:53:55.431190 [ 17371 ] {a33a7b45-85e5-4d32-8411-f7a47a107b18} executeQuery: Code: 420. DB::Exception: Cannot update column `json` with type JSON: updates of columns with dynamic subcolumns are not supported. (CANNOT_UPDATE_COLUMN) (version 25.3.6.10636.altinitytest (altinity build)) (from 0.0.0.0:0) (comment: 03226_alter_update_dynamic_json_not_supported.sql) (in query: /* ddl_entry=query-0000000004 */ ALTER TABLE test_8kn8txev.test (UPDATE json = '{}' WHERE 1)), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000a06a8eb 4. /build/src/Interpreters/MutationsInterpreter.cpp:1426: DB::MutationsInterpreter::validate() @ 0x0000000014a31b94 5. /build/src/Interpreters/InterpreterAlterQuery.cpp:235: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x00000000148deddb 6. /build/src/Interpreters/InterpreterAlterQuery.cpp:77: DB::InterpreterAlterQuery::execute() @ 0x00000000148dcb0d 7. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88dc9 8. /build/src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x0000000014c8ca7b 9. /build/src/Interpreters/DDLWorker.cpp:510: DB::DDLWorker::tryExecuteQuery(DB::DDLTaskBase&, std::shared_ptr const&, bool) @ 0x00000000144dab9e 10. /build/src/Interpreters/DDLWorker.cpp:675: DB::DDLWorker::processTask(DB::DDLTaskBase&, std::shared_ptr const&, bool) @ 0x00000000144d8ffe 11. /build/src/Databases/DatabaseReplicatedWorker.cpp:372: DB::DatabaseReplicatedDDLWorker::tryEnqueueAndExecuteEntry(DB::DDLLogEntry&, std::shared_ptr, bool) @ 0x0000000013dc29ab 12. /build/src/Databases/DatabaseReplicated.cpp:1139: DB::DatabaseReplicated::tryEnqueueReplicatedDDL(std::shared_ptr const&, std::shared_ptr, DB::QueryFlags) @ 0x0000000013d9f73c 13. /build/src/Interpreters/InterpreterAlterQuery.cpp:130: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x00000000148dd805 14. /build/src/Interpreters/InterpreterAlterQuery.cpp:77: DB::InterpreterAlterQuery::execute() @ 0x00000000148dcb0d 15. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88dc9 16. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 17. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 18. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 19. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 20. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 21. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 22. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 23. ? @ 0x00007fbc6213eac3 24. ? @ 0x00007fbc621d0850 2025.07.28 11:53:55.433813 [ 5327 ] {} TCPHandler: Code: 210. DB::NetException: Connection reset by peer, while writing to socket ([::ffff:127.0.0.3]:9000 -> [::ffff:127.0.0.1]:59972). (NETWORK_ERROR), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::NetException::NetException(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&) @ 0x000000000fd50fb5 3. /build/src/IO/WriteBufferFromPocoSocket.cpp:160: DB::WriteBufferFromPocoSocket::nextImpl() @ 0x000000000fd523f1 4. /build/src/IO/WriteBuffer.h:53: DB::WriteBuffer::next() @ 0x000000000a0755be 5. /build/src/Server/TCPHandler.cpp:2490: DB::TCPHandler::sendData(DB::QueryState&, DB::Block const&) @ 0x00000000168fa306 6. /build/src/Server/TCPHandler.cpp:1266: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x00000000168f162c 7. /build/src/Server/TCPHandler.cpp:678: DB::TCPHandler::runImpl() @ 0x00000000168e68e5 8. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 9. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 10. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 11. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 12. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 13. ? @ 0x00007fbc6213eac3 14. ? @ 0x00007fbc621d0850 2025.07.28 11:53:55.446374 [ 17371 ] {a33a7b45-85e5-4d32-8411-f7a47a107b18} executeQuery: Code: 420. DB::Exception: Cannot update column `json` with type JSON: updates of columns with dynamic subcolumns are not supported. (CANNOT_UPDATE_COLUMN) (version 25.3.6.10636.altinitytest (altinity build)) (from [::1]:60344) (comment: 03226_alter_update_dynamic_json_not_supported.sql) (query 6, line 7) (in query: alter table test update json = '{}' where 1;), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000a06a8eb 4. /build/src/Interpreters/MutationsInterpreter.cpp:1426: DB::MutationsInterpreter::validate() @ 0x0000000014a31b94 5. /build/src/Interpreters/InterpreterAlterQuery.cpp:235: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x00000000148deddb 6. /build/src/Interpreters/InterpreterAlterQuery.cpp:77: DB::InterpreterAlterQuery::execute() @ 0x00000000148dcb0d 7. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88dc9 8. /build/src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x0000000014c8ca7b 9. /build/src/Interpreters/DDLWorker.cpp:510: DB::DDLWorker::tryExecuteQuery(DB::DDLTaskBase&, std::shared_ptr const&, bool) @ 0x00000000144dab9e 10. /build/src/Interpreters/DDLWorker.cpp:675: DB::DDLWorker::processTask(DB::DDLTaskBase&, std::shared_ptr const&, bool) @ 0x00000000144d8ffe 11. /build/src/Databases/DatabaseReplicatedWorker.cpp:372: DB::DatabaseReplicatedDDLWorker::tryEnqueueAndExecuteEntry(DB::DDLLogEntry&, std::shared_ptr, bool) @ 0x0000000013dc29ab 12. /build/src/Databases/DatabaseReplicated.cpp:1139: DB::DatabaseReplicated::tryEnqueueReplicatedDDL(std::shared_ptr const&, std::shared_ptr, DB::QueryFlags) @ 0x0000000013d9f73c 13. /build/src/Interpreters/InterpreterAlterQuery.cpp:130: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x00000000148dd805 14. /build/src/Interpreters/InterpreterAlterQuery.cpp:77: DB::InterpreterAlterQuery::execute() @ 0x00000000148dcb0d 15. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88dc9 16. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 17. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 18. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 19. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 20. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 21. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 22. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 23. ? @ 0x00007fbc6213eac3 24. ? @ 0x00007fbc621d0850 2025.07.28 11:53:55.449867 [ 17371 ] {} TCPHandler: Code: 420. DB::Exception: Cannot update column `json` with type JSON: updates of columns with dynamic subcolumns are not supported. (CANNOT_UPDATE_COLUMN), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000a06a8eb 4. /build/src/Interpreters/MutationsInterpreter.cpp:1426: DB::MutationsInterpreter::validate() @ 0x0000000014a31b94 5. /build/src/Interpreters/InterpreterAlterQuery.cpp:235: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x00000000148deddb 6. /build/src/Interpreters/InterpreterAlterQuery.cpp:77: DB::InterpreterAlterQuery::execute() @ 0x00000000148dcb0d 7. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88dc9 8. /build/src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x0000000014c8ca7b 9. /build/src/Interpreters/DDLWorker.cpp:510: DB::DDLWorker::tryExecuteQuery(DB::DDLTaskBase&, std::shared_ptr const&, bool) @ 0x00000000144dab9e 10. /build/src/Interpreters/DDLWorker.cpp:675: DB::DDLWorker::processTask(DB::DDLTaskBase&, std::shared_ptr const&, bool) @ 0x00000000144d8ffe 11. /build/src/Databases/DatabaseReplicatedWorker.cpp:372: DB::DatabaseReplicatedDDLWorker::tryEnqueueAndExecuteEntry(DB::DDLLogEntry&, std::shared_ptr, bool) @ 0x0000000013dc29ab 12. /build/src/Databases/DatabaseReplicated.cpp:1139: DB::DatabaseReplicated::tryEnqueueReplicatedDDL(std::shared_ptr const&, std::shared_ptr, DB::QueryFlags) @ 0x0000000013d9f73c 13. /build/src/Interpreters/InterpreterAlterQuery.cpp:130: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x00000000148dd805 14. /build/src/Interpreters/InterpreterAlterQuery.cpp:77: DB::InterpreterAlterQuery::execute() @ 0x00000000148dcb0d 15. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88dc9 16. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 17. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 18. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 19. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 20. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 21. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 22. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 23. ? @ 0x00007fbc6213eac3 24. ? @ 0x00007fbc621d0850 2025.07.28 11:53:55.976779 [ 17191 ] {460eaa47-06be-48f7-a7f7-80d8835965c1} executeQuery: Code: 153. DB::Exception: Division by zero: while executing 'FUNCTION modulo(1_UInt8 :: 1, modulo(plus(__table1.number, 500_UInt16), 1000_UInt16) :: 2) -> modulo(1_UInt8, modulo(plus(__table1.number, 500_UInt16), 1000_UInt16)) UInt16 : 3'. (ILLEGAL_DIVISION) (version 25.3.6.10636.altinitytest (altinity build)) (from [::1]:60266) (comment: 00093_union_race_conditions_4.sh) (query 1, line 1) (in query: SELECT 1 % ((number + 500) % 1000) FROM numbers_mt(1000);), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000000a074fcb 4. /build/src/Functions/DivisionUtils.h:26: void DB::impl_::BinaryOperation, unsigned short>::process<(DB::impl_::OpCase)1>(char8_t const*, unsigned short const*, unsigned short*, unsigned long, DB::PODArray, 63ul, 64ul> const*) @ 0x000000000d184621 5. /build/src/Functions/FunctionBinaryArithmetic.h:2338: COW::immutable_ptr DB::FunctionBinaryArithmetic::executeNumeric, DB::DataTypeNumber>(std::vector> const&, DB::DataTypeNumber const&, DB::DataTypeNumber const&, DB::PODArray, 63ul, 64ul> const*) const @ 0x000000000d3a6416 6. /build/src/Functions/FunctionBinaryArithmetic.h:2508: 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&&) @ 0x000000000d3a4a68 7. /build/src/Functions/FunctionBinaryArithmetic.h:846: 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&&) @ 0x000000000d3a3ec7 8. /build/src/Functions/FunctionBinaryArithmetic.h:844: DB::FunctionBinaryArithmetic::executeImpl2(std::vector> const&, std::shared_ptr const&, unsigned long, DB::PODArray, 63ul, 64ul> const*) const @ 0x000000000d3a03c5 9. /build/src/Functions/FunctionBinaryArithmetic.h:2410: DB::FunctionBinaryArithmetic::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000d39e94c 10. /build/src/Functions/FunctionBinaryArithmetic.h:2645: DB::FunctionBinaryArithmeticWithConstants::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000d39dbd4 11. /build/src/Functions/IFunctionAdaptors.cpp:10: DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000012d995fa 12. /build/src/Functions/IFunction.cpp:353: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d93b52 13. /build/src/Functions/IFunction.cpp:420: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d95059 14. /build/src/Functions/IFunction.cpp:498: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d95c72 15. /build/src/Interpreters/ExpressionActions.cpp:636: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x00000000145176f3 16. /build/src/Processors/Transforms/ExpressionTransform.cpp:25: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x0000000016c0b34c 17. /build/src/Processors/ISimpleTransform.h:33: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000011a9a453 18. /build/src/Processors/ISimpleTransform.cpp:89: DB::ISimpleTransform::work() @ 0x000000001699fca0 19. /build/src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x00000000169bd00f 20. /build/src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x00000000169b2105 21. /build/src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeSingleThread(unsigned long) @ 0x00000000169b23be 22. /build/src/Processors/Executors/PipelineExecutor.cpp:454: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x00000000169b0be7 23. /build/src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x00000000169b03f4 24. /build/src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:se190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169bfeab 25. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc3d92 26. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fcca080 27. ? @ 0x00007fbc6213eac3 28. ? @ 0x00007fbc621d0850 2025.07.28 11:53:56.018130 [ 17191 ] {} TCPHandler: Code: 153. DB::Exception: Division by zero: while executing 'FUNCTION modulo(1_UInt8 :: 1, modulo(plus(__table1.number, 500_UInt16), 1000_UInt16) :: 2) -> modulo(1_UInt8, modulo(plus(__table1.number, 500_UInt16), 1000_UInt16)) UInt16 : 3'. (ILLEGAL_DIVISION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000000a074fcb 4. /build/src/Functions/DivisionUtils.h:26: void DB::impl_::BinaryOperation, unsigned short>::process<(DB::impl_::OpCase)1>(char8_t const*, unsigned short const*, unsigned short*, unsigned long, DB::PODArray, 63ul, 64ul> const*) @ 0x000000000d184621 5. /build/src/Functions/FunctionBinaryArithmetic.h:2338: COW::immutable_ptr DB::FunctionBinaryArithmetic::executeNumeric, DB::DataTypeNumber>(std::vector> const&, DB::DataTypeNumber const&, DB::DataTypeNumber const&, DB::PODArray, 63ul, 64ul> const*) const @ 0x000000000d3a6416 6. /build/src/Functions/FunctionBinaryArithmetic.h:2508: 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&&) @ 0x000000000d3a4a68 7. /build/src/Functions/FunctionBinaryArithmetic.h:846: 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&&) @ 0x000000000d3a3ec7 8. /build/src/Functions/FunctionBinaryArithmetic.h:844: DB::FunctionBinaryArithmetic::executeImpl2(std::vector> const&, std::shared_ptr const&, unsigned long, DB::PODArray, 63ul, 64ul> const*) const @ 0x000000000d3a03c5 9. /build/src/Functions/FunctionBinaryArithmetic.h:2410: DB::FunctionBinaryArithmetic::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000d39e94c 10. /build/src/Functions/FunctionBinaryArithmetic.h:2645: DB::FunctionBinaryArithmeticWithConstants::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000d39dbd4 11. /build/src/Functions/IFunctionAdaptors.cpp:10: DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000012d995fa 12. /build/src/Functions/IFunction.cpp:353: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d93b52 13. /build/src/Functions/IFunction.cpp:420: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d95059 14. /build/src/Functions/IFunction.cpp:498: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d95c72 15. /build/src/Interpreters/ExpressionActions.cpp:636: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x00000000145176f3 16. /build/src/Processors/Transforms/ExpressionTransform.cpp:25: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x0000000016c0b34c 17. /build/src/Processors/ISimpleTransform.h:33: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000011a9a453 18. /build/src/Processors/ISimpleTransform.cpp:89: DB::ISimpleTransform::work() @ 0x000000001699fca0 19. /build/src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x00000000169bd00f 20. /build/src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x00000000169b2105 21. /build/src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeSingleThread(unsigned long) @ 0x00000000169b23be 22. /build/src/Processors/Executors/PipelineExecutor.cpp:454: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x00000000169b0be7 23. /build/src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x00000000169b03f4 24. /build/src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:se190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169bfeab 25. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc3d92 26. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fcca080 27. ? @ 0x00007fbc6213eac3 28. ? @ 0x00007fbc621d0850 Job's origin stack trace: 0. /build/src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000000fc33b84 1. /build/src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000000fcc2ea7 2. /build/src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fcc535c 3. /build/src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000000fcc584d 4. /build/src/Common/ThreadPool.h:279: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x00000000169bf193 5. /build/src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x00000000169bf518 6. /build/src/Server/TCPHandler.cpp:1237: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x00000000168f1525 7. /build/src/Server/TCPHandler.cpp:678: DB::TCPHandler::runImpl() @ 0x00000000168e68e5 8. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 9. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 10. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 11. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 12. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 13. ? @ 0x00007fbc6213eac3 14. ? @ 0x00007fbc621d0850 2025.07.28 11:53:56.362840 [ 17203 ] {dda04c51-8c48-47b0-abb3-e40a30565908} executeQuery: Code: 100. DB::Exception: Unknown packet 9223372036854775807 from server 127.0.0.2:9000: While executing Remote. (UNKNOWN_PACKET_FROM_SERVER) (version 25.3.6.10636.altinitytest (altinity build)) (from [::1]:60408) (comment: 01822_async_read_from_socket_crash.sh) (query 1, line 1) (in query: select number from remote('127.0.0.{2,3}', numbers(20)) limit 8 settings max_block_size = 2, unknown_packet_in_send_data=4, sleep_in_send_data_ms=100, async_socket_for_remote=1 format Null), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String const&) @ 0x000000000a68756b 4. /build/src/Client/Connection.cpp:1323: DB::Connection::receivePacket() @ 0x00000000167db7d2 5. /build/src/Client/PacketReceiver.cpp:66: DB::PacketReceiver::Task::run(std::function, std::function) @ 0x0000000016819393 6. /build/src/Common/AsyncTaskExecutor.cpp:89: DB::AsyncTaskExecutor::Routine::operator()(std::function) @ 0x0000000013bd1892 7. /build/src/Common/Fiber.h:76: boost::context::detail::fiber_record>::run(void*) @ 0x0000000013bd16fa 8. /build/contrib/boost/boost/context/fiber_fcontext.hpp:97: void boost::context::detail::fiber_entry>>(boost::context::detail::transfer_t) @ 0x0000000013bd1621 2025.07.28 11:53:56.372580 [ 17611 ] {938e75b4-2b13-4fd4-8d30-8c430773200e} executeQuery: Code: 48. DB::Exception: Conversion between numeric types and UUID is not supported. Probably the passed UUID is unquoted: In scope SELECT toUInt64(toUUID('00000000-0000-0000-0000-000000000000')). (NOT_IMPLEMENTED) (version 25.3.6.10636.altinitytest (altinity build)) (from [::1]:60418) (comment: 02810_convert_uuid_to_uint128.sql) (query 4, line 4) (in query: SELECT toUInt64(toUUID('00000000-0000-0000-0000-000000000000'));), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000000a074fcb 4. /build/src/Functions/FunctionsConversion.h:1716: COW::immutable_ptr DB::detail::ConvertImpl, DB::detail::NameToUInt64, (DB::FormatSettings::DateTimeOverflowBehavior)0>::execute(std::vector> const&, std::shared_ptr const&, unsigned long, DB::detail::BehaviourOnErrorFromString, void*) @ 0x0000000012ff907b 5. /build/src/Functions/FunctionsConversion.h:2472: 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&&) @ 0x0000000012f9e104 6. /build/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 @ 0x0000000012fb254e 7. /build/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 @ 0x0000000012fb1d7a 8. /build/src/Functions/IFunction.h:437: DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000a069f2a 9. /build/src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000012d9965a 10. /build/src/Functions/IFunction.cpp:351: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d93b02 11. /build/src/Functions/IFunction.cpp:177: DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d93698 12. /build/src/Functions/IFunction.cpp:343: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d93aad 13. /build/src/Functions/IFunction.cpp:420: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d95059 14. /build/src/Functions/IFunction.cpp:498: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d95c72 15. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3567: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000014034494 16. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3838: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000014019a9e 17. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3980: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000014018e31 18. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:4304: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000014042fa7 19. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5605: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000014013749 20. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000140127f9 21. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000014011fce 22. /build/src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000001406ce8a 23. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000014973b42 24. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000001497268d 25. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000014974d24 26. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001492924b 27. /build/src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88641 28. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 29. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 30. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 31. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 2025.07.28 11:53:56.382308 [ 5327 ] {0e006f51-b87e-4282-9c31-47f615108b89} executeQuery: Code: 236. DB::NetException: Client has dropped the connection, cancel the query. (ABORTED) (version 25.3.6.10636.altinitytest (altinity build)) (from [::ffff:127.0.0.1]:41018) (comment: 01822_async_read_from_socket_crash.sh) (query 1, line 1) (in query: SELECT `__table1`.`number` AS `number` FROM numbers(20) AS `__table1` LIMIT _CAST(8, 'UInt64')), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::NetException::NetException(int, T&&) @ 0x0000000016900f80 3. /build/src/Server/TCPHandler.cpp:2426: DB::TCPHandler::receivePacketsExpectCancel(DB::QueryState&) @ 0x00000000168fba18 4. /build/src/Server/TCPHandler.cpp:1242: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x00000000168f1540 5. /build/src/Server/TCPHandler.cpp:678: DB::TCPHandler::runImpl() @ 0x00000000168e68e5 6. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 7. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 8. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 9. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 10. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 11. ? @ 0x00007fbc6213eac3 12. ? @ 0x00007fbc621d0850 2025.07.28 11:53:56.384605 [ 17611 ] {} TCPHandler: Code: 48. DB::Exception: Conversion between numeric types and UUID is not supported. Probably the passed UUID is unquoted: In scope SELECT toUInt64(toUUID('00000000-0000-0000-0000-000000000000')). (NOT_IMPLEMENTED), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000000a074fcb 4. /build/src/Functions/FunctionsConversion.h:1716: COW::immutable_ptr DB::detail::ConvertImpl, DB::detail::NameToUInt64, (DB::FormatSettings::DateTimeOverflowBehavior)0>::execute(std::vector> const&, std::shared_ptr const&, unsigned long, DB::detail::BehaviourOnErrorFromString, void*) @ 0x0000000012ff907b 5. /build/src/Functions/FunctionsConversion.h:2472: 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&&) @ 0x0000000012f9e104 6. /build/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 @ 0x0000000012fb254e 7. /build/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 @ 0x0000000012fb1d7a 8. /build/src/Functions/IFunction.h:437: DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000a069f2a 9. /build/src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000012d9965a 10. /build/src/Functions/IFunction.cpp:351: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d93b02 11. /build/src/Functions/IFunction.cpp:177: DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d93698 12. /build/src/Functions/IFunction.cpp:343: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d93aad 13. /build/src/Functions/IFunction.cpp:420: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d95059 14. /build/src/Functions/IFunction.cpp:498: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d95c72 15. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3567: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000014034494 16. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3838: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000014019a9e 17. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3980: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000014018e31 18. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:4304: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000014042fa7 19. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5605: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000014013749 20. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000140127f9 21. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000014011fce 22. /build/src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000001406ce8a 23. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000014973b42 24. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000001497268d 25. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000014974d24 26. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001492924b 27. /build/src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88641 28. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 29. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 30. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 31. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 2025.07.28 11:53:56.386800 [ 17203 ] {} TCPHandler: Code: 100. DB::Exception: Unknown packet 9223372036854775807 from server 127.0.0.2:9000: While executing Remote. (UNKNOWN_PACKET_FROM_SERVER), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String const&) @ 0x000000000a68756b 4. /build/src/Client/Connection.cpp:1323: DB::Connection::receivePacket() @ 0x00000000167db7d2 5. /build/src/Client/PacketReceiver.cpp:66: DB::PacketReceiver::Task::run(std::function, std::function) @ 0x0000000016819393 6. /build/src/Common/AsyncTaskExecutor.cpp:89: DB::AsyncTaskExecutor::Routine::operator()(std::function) @ 0x0000000013bd1892 7. /build/src/Common/Fiber.h:76: boost::context::detail::fiber_record>::run(void*) @ 0x0000000013bd16fa 8. /build/contrib/boost/boost/context/fiber_fcontext.hpp:97: void boost::context::detail::fiber_entry>>(boost::context::detail::transfer_t) @ 0x0000000013bd1621 Job's origin stack trace: 0. /build/src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000000fc33b84 1. /build/src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000000fcc2ea7 2. /build/src/Common/ThreadPool.cpp:401: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fcc7f1c 3. /build/src/Common/ThreadPool.cpp:494: ThreadPoolImpl>::scheduleOrThrowOnError(std::function, Priority) @ 0x000000000fcc7a0e 4. /build/src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::spawnThreadsImpl() @ 0x00000000169b2c0c 5. /build/src/Processors/Executors/PipelineExecutor.cpp:394: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x00000000169b0ba7 6. /build/src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x00000000169b03f4 7. /build/src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:se190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169bfeab 8. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc3d92 9. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fcca080 10. ? @ 0x00007fbc6213eac3 11. ? @ 0x00007fbc621d0850 Job's origin stack trace: 0. /build/src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000000fc33b84 1. /build/src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000000fcc2ea7 2. /build/src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fcc535c 3. /build/src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000000fcc584d 4. /build/src/Common/ThreadPool.h:279: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x00000000169bf193 5. /build/src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x00000000169bf518 6. /build/src/Server/TCPHandler.cpp:1237: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x00000000168f1525 7. /build/src/Server/TCPHandler.cpp:678: DB::TCPHandler::runImpl() @ 0x00000000168e68e5 8. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 9. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 10. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 11. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 12. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 13. ? @ 0x00007fbc6213eac3 14. ? @ 0x00007fbc621d0850 2025.07.28 11:53:56.390453 [ 3963 ] {} test_13.rmt2 (7f9b740d-015c-470e-8cc6-8ba33be0dc63): auto DB::StorageReplicatedMergeTree::processQueueEntry(ReplicatedMergeTreeQueue::SelectedEntryPtr)::(anonymous class)::operator()(LogEntryPtr &) const: Code: 86. DB::HTTPException: Received error from remote server http://146b4357c08d:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Ftest%2F01165%2Ftest_13%2Frmt%2Freplicas%2F1&part=20250728_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.6.10636.altinitytest (altinity build)) '. (RECEIVED_ERROR_FROM_REMOTE_IO_SERVER), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.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 const&, int&&, String const&, unsigned long&&, String const&) @ 0x000000000feda8d9 4. /build/src/IO/HTTPCommon.cpp:104: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x000000000feda6e2 5. /build/src/IO/HTTPCommon.cpp:93: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x000000000feda537 6. /build/src/IO/ReadWriteBufferFromHTTP.cpp:277: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x000000001184a4c4 7. /build/src/IO/ReadWriteBufferFromHTTP.cpp:285: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x000000001184a615 8. /build/src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x000000001184ae59 9. /build/src/IO/ReadWriteBufferFromHTTP.cpp:472: void std::__function::__policy_invoker::__call_impl[abi:se190107]>(std::__function::__policy_storage const*) @ 0x000000001184cedd 10. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001184858b 11. /build/src/IO/ReadWriteBufferFromHTTP.cpp:465: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x000000001184bf0b 12. /build/src/IO/ReadBuffer.h:60: DB::ReadBuffer::next() @ 0x000000000a148c7b 13. /build/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) @ 0x0000000011849fb2 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]>&)>&, 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&) @ 0x0000000011841980 15. /build/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) @ 0x000000001621208e 16. /build/src/Storages/StorageReplicatedMergeTree.cpp:5228: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl[abi:se190107] const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000015f9a5fe 17. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000015ed8bfd 18. /build/src/Storages/StorageReplicatedMergeTree.cpp:2514: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x0000000015ec9aab 19. /build/src/Storages/StorageReplicatedMergeTree.cpp:2349: DB::StorageReplicatedMergeTree::executeLogEntry(DB::ReplicatedMergeTreeLogEntry&) @ 0x0000000015eba91b 20. /build/src/Storages/StorageReplicatedMergeTree.cpp:3876: bool std::__function::__policy_invoker&)>::__call_impl[abi:se190107])::$_1, bool (std::shared_ptr&)>>(std::__function::__policy_storage const*, std::shared_ptr&) @ 0x0000000015f9837e 21. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000165d6fc3 22. /build/src/Storages/StorageReplicatedMergeTree.cpp:3872: DB::StorageReplicatedMergeTree::processQueueEntry(std::shared_ptr) @ 0x0000000015efc18a 23. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001624c1b2 24. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000162f9c70 25. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x00000000162fa55a 26. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc6653 27. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000000fccc4c3 28. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc3d92 29. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fcca080 30. ? @ 0x00007fbc6213eac3 31. ? @ 0x00007fbc621d0850 (version 25.3.6.10636.altinitytest (altinity build)) 2025.07.28 11:53:56.432522 [ 17208 ] {299ebc89-b0b3-4f3e-9b26-d9c7028105bb} 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]:59986). (NETWORK_ERROR), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::NetException::NetException(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&) @ 0x000000000fd50fb5 3. /build/src/IO/WriteBufferFromPocoSocket.cpp:160: DB::WriteBufferFromPocoSocket::nextImpl() @ 0x000000000fd523f1 4. /build/src/IO/WriteBuffer.h:53: DB::WriteBuffer::next() @ 0x000000000a0755be 5. /build/src/Server/TCPHandler.cpp:2490: DB::TCPHandler::sendData(DB::QueryState&, DB::Block const&) @ 0x00000000168fa306 6. /build/src/Server/TCPHandler.cpp:1266: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x00000000168f162c 7. /build/src/Server/TCPHandler.cpp:678: DB::TCPHandler::runImpl() @ 0x00000000168e68e5 8. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 9. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 10. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 11. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 12. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 13. ? @ 0x00007fbc6213eac3 14. ? @ 0x00007fbc621d0850 (version 25.3.6.10636.altinitytest (altinity build)) 2025.07.28 11:53:56.445650 [ 17208 ] {299ebc89-b0b3-4f3e-9b26-d9c7028105bb} executeQuery: Code: 210. DB::NetException: Connection reset by peer, while writing to socket ([::ffff:127.0.0.3]:9000 -> [::ffff:127.0.0.1]:59986). (NETWORK_ERROR) (version 25.3.6.10636.altinitytest (altinity build)) (from [::ffff:127.0.0.1]:59986) (comment: 01822_async_read_from_socket_crash.sh) (query 1, line 1) (in query: SELECT `__table1`.`number` AS `number` FROM numbers(20) AS `__table1` LIMIT _CAST(8, 'UInt64')), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::NetException::NetException(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&) @ 0x000000000fd50fb5 3. /build/src/IO/WriteBufferFromPocoSocket.cpp:160: DB::WriteBufferFromPocoSocket::nextImpl() @ 0x000000000fd523f1 4. /build/src/IO/WriteBuffer.h:53: DB::WriteBuffer::next() @ 0x000000000a0755be 5. /build/src/Server/TCPHandler.cpp:2490: DB::TCPHandler::sendData(DB::QueryState&, DB::Block const&) @ 0x00000000168fa306 6. /build/src/Server/TCPHandler.cpp:1266: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x00000000168f162c 7. /build/src/Server/TCPHandler.cpp:678: DB::TCPHandler::runImpl() @ 0x00000000168e68e5 8. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 9. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 10. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 11. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 12. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 13. ? @ 0x00007fbc6213eac3 14. ? @ 0x00007fbc621d0850 2025.07.28 11:53:56.447305 [ 5327 ] {0e006f51-b87e-4282-9c31-47f615108b89} 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]:41018). (NETWORK_ERROR), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::NetException::NetException(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&) @ 0x000000000fd50fb5 3. /build/src/IO/WriteBufferFromPocoSocket.cpp:171: DB::WriteBufferFromPocoSocket::nextImpl() @ 0x000000000fd525a7 4. /build/src/IO/WriteBuffer.h:53: DB::WriteBuffer::next() @ 0x000000000a0755be 5. /build/src/Server/TCPHandler.cpp:2620: DB::TCPHandler::sendLogs(DB::QueryState&) @ 0x00000000168f1e17 6. /build/src/Server/TCPHandler.cpp:821: DB::TCPHandler::runImpl() @ 0x00000000168e6c63 7. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 8. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 9. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 10. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 11. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 12. ? @ 0x00007fbc6213eac3 13. ? @ 0x00007fbc621d0850 (version 25.3.6.10636.altinitytest (altinity build)) 2025.07.28 11:53:56.449944 [ 5327 ] {} 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. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::NetException::NetException(int, T&&) @ 0x0000000016900f80 3. /build/src/Server/TCPHandler.cpp:2426: DB::TCPHandler::receivePacketsExpectCancel(DB::QueryState&) @ 0x00000000168fba18 4. /build/src/Server/TCPHandler.cpp:1242: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x00000000168f1540 5. /build/src/Server/TCPHandler.cpp:678: DB::TCPHandler::runImpl() @ 0x00000000168e68e5 6. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 7. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 8. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 9. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 10. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 11. ? @ 0x00007fbc6213eac3 12. ? @ 0x00007fbc621d0850 2025.07.28 11:53:56.450119 [ 17208 ] {} TCPHandler: Code: 210. DB::NetException: Connection reset by peer, while writing to socket ([::ffff:127.0.0.3]:9000 -> [::ffff:127.0.0.1]:59986). (NETWORK_ERROR), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::NetException::NetException(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&) @ 0x000000000fd50fb5 3. /build/src/IO/WriteBufferFromPocoSocket.cpp:160: DB::WriteBufferFromPocoSocket::nextImpl() @ 0x000000000fd523f1 4. /build/src/IO/WriteBuffer.h:53: DB::WriteBuffer::next() @ 0x000000000a0755be 5. /build/src/Server/TCPHandler.cpp:2490: DB::TCPHandler::sendData(DB::QueryState&, DB::Block const&) @ 0x00000000168fa306 6. /build/src/Server/TCPHandler.cpp:1266: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x00000000168f162c 7. /build/src/Server/TCPHandler.cpp:678: DB::TCPHandler::runImpl() @ 0x00000000168e68e5 8. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 9. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 10. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 11. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 12. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 13. ? @ 0x00007fbc6213eac3 14. ? @ 0x00007fbc621d0850 2025.07.28 11:53:56.517120 [ 17611 ] {0d1457d7-1ce6-4245-83b8-d25f8283db8d} executeQuery: Code: 48. DB::Exception: Conversion between numeric types and UUID is not supported. Probably the passed UUID is unquoted: In scope SELECT toInt128(toUUID('00000000-0000-0000-0000-000000000000')). (NOT_IMPLEMENTED) (version 25.3.6.10636.altinitytest (altinity build)) (from [::1]:60418) (comment: 02810_convert_uuid_to_uint128.sql) (query 5, line 5) (in query: SELECT toInt128(toUUID('00000000-0000-0000-0000-000000000000'));), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000000a074fcb 4. /build/src/Functions/FunctionsConversion.h:1716: COW::immutable_ptr DB::detail::ConvertImpl>, DB::detail::NameToInt128, (DB::FormatSettings::DateTimeOverflowBehavior)0>::execute(std::vector> const&, std::shared_ptr const&, unsigned long, DB::detail::BehaviourOnErrorFromString, void*) @ 0x000000001303969b 5. /build/src/Functions/FunctionsConversion.h:2472: bool DB::callOnIndexAndDataType>, DB::detail::FunctionConvert>, DB::detail::NameToInt128, 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::NameToInt128, DB::detail::ToNumberMonotonicity>>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::detail::BehaviourOnErrorFromString)&, DB::detail::BehaviourOnErrorFromString&&) @ 0x0000000012fa4064 6. /build/src/Functions/FunctionsConversion.h:2527: DB::detail::FunctionConvert>, DB::detail::NameToInt128, DB::detail::ToNumberMonotonicity>>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000012fbab2e 7. /build/src/Functions/FunctionsConversion.h:2307: DB::detail::FunctionConvert>, DB::detail::NameToInt128, DB::detail::ToNumberMonotonicity>>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000012fba35a 8. /build/src/Functions/IFunction.h:437: DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000a069f2a 9. /build/src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000012d9965a 10. /build/src/Functions/IFunction.cpp:351: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d93b02 11. /build/src/Functions/IFunction.cpp:177: DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d93698 12. /build/src/Functions/IFunction.cpp:343: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d93aad 13. /build/src/Functions/IFunction.cpp:420: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d95059 14. /build/src/Functions/IFunction.cpp:498: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d95c72 15. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3567: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000014034494 16. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3838: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000014019a9e 17. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3980: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000014018e31 18. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:4304: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000014042fa7 19. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5605: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000014013749 20. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000140127f9 21. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000014011fce 22. /build/src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000001406ce8a 23. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000014973b42 24. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000001497268d 25. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000014974d24 26. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001492924b 27. /build/src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88641 28. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 29. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 30. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 31. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 2025.07.28 11:53:56.543612 [ 17611 ] {} TCPHandler: Code: 48. DB::Exception: Conversion between numeric types and UUID is not supported. Probably the passed UUID is unquoted: In scope SELECT toInt128(toUUID('00000000-0000-0000-0000-000000000000')). (NOT_IMPLEMENTED), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000000a074fcb 4. /build/src/Functions/FunctionsConversion.h:1716: COW::immutable_ptr DB::detail::ConvertImpl>, DB::detail::NameToInt128, (DB::FormatSettings::DateTimeOverflowBehavior)0>::execute(std::vector> const&, std::shared_ptr const&, unsigned long, DB::detail::BehaviourOnErrorFromString, void*) @ 0x000000001303969b 5. /build/src/Functions/FunctionsConversion.h:2472: bool DB::callOnIndexAndDataType>, DB::detail::FunctionConvert>, DB::detail::NameToInt128, 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::NameToInt128, DB::detail::ToNumberMonotonicity>>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::detail::BehaviourOnErrorFromString)&, DB::detail::BehaviourOnErrorFromString&&) @ 0x0000000012fa4064 6. /build/src/Functions/FunctionsConversion.h:2527: DB::detail::FunctionConvert>, DB::detail::NameToInt128, DB::detail::ToNumberMonotonicity>>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000012fbab2e 7. /build/src/Functions/FunctionsConversion.h:2307: DB::detail::FunctionConvert>, DB::detail::NameToInt128, DB::detail::ToNumberMonotonicity>>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000012fba35a 8. /build/src/Functions/IFunction.h:437: DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000a069f2a 9. /build/src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000012d9965a 10. /build/src/Functions/IFunction.cpp:351: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d93b02 11. /build/src/Functions/IFunction.cpp:177: DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d93698 12. /build/src/Functions/IFunction.cpp:343: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d93aad 13. /build/src/Functions/IFunction.cpp:420: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d95059 14. /build/src/Functions/IFunction.cpp:498: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d95c72 15. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3567: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000014034494 16. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3838: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000014019a9e 17. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3980: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000014018e31 18. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:4304: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000014042fa7 19. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5605: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000014013749 20. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000140127f9 21. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000014011fce 22. /build/src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000001406ce8a 23. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000014973b42 24. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000001497268d 25. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000014974d24 26. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001492924b 27. /build/src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88641 28. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 29. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 30. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 31. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 2025.07.28 11:53:56.871652 [ 3961 ] {} test_13.rmt2 (7f9b740d-015c-470e-8cc6-8ba33be0dc63): auto DB::StorageReplicatedMergeTree::processQueueEntry(ReplicatedMergeTreeQueue::SelectedEntryPtr)::(anonymous class)::operator()(LogEntryPtr &) const: Code: 86. DB::HTTPException: Received error from remote server http://146b4357c08d:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Ftest%2F01165%2Ftest_13%2Frmt%2Freplicas%2F1&part=20250728_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.6.10636.altinitytest (altinity build)) '. (RECEIVED_ERROR_FROM_REMOTE_IO_SERVER), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.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 const&, int&&, String const&, unsigned long&&, String const&) @ 0x000000000feda8d9 4. /build/src/IO/HTTPCommon.cpp:104: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x000000000feda6e2 5. /build/src/IO/HTTPCommon.cpp:93: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x000000000feda537 6. /build/src/IO/ReadWriteBufferFromHTTP.cpp:277: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x000000001184a4c4 7. /build/src/IO/ReadWriteBufferFromHTTP.cpp:285: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x000000001184a615 8. /build/src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x000000001184ae59 9. /build/src/IO/ReadWriteBufferFromHTTP.cpp:472: void std::__function::__policy_invoker::__call_impl[abi:se190107]>(std::__function::__policy_storage const*) @ 0x000000001184cedd 10. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001184858b 11. /build/src/IO/ReadWriteBufferFromHTTP.cpp:465: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x000000001184bf0b 12. /build/src/IO/ReadBuffer.h:60: DB::ReadBuffer::next() @ 0x000000000a148c7b 13. /build/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) @ 0x0000000011849fb2 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]>&)>&, 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&) @ 0x0000000011841980 15. /build/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) @ 0x000000001621208e 16. /build/src/Storages/StorageReplicatedMergeTree.cpp:5228: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl[abi:se190107] const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000015f9a5fe 17. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000015ed8bfd 18. /build/src/Storages/StorageReplicatedMergeTree.cpp:2514: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x0000000015ec9aab 19. /build/src/Storages/StorageReplicatedMergeTree.cpp:2349: DB::StorageReplicatedMergeTree::executeLogEntry(DB::ReplicatedMergeTreeLogEntry&) @ 0x0000000015eba91b 20. /build/src/Storages/StorageReplicatedMergeTree.cpp:3876: bool std::__function::__policy_invoker&)>::__call_impl[abi:se190107])::$_1, bool (std::shared_ptr&)>>(std::__function::__policy_storage const*, std::shared_ptr&) @ 0x0000000015f9837e 21. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000165d6fc3 22. /build/src/Storages/StorageReplicatedMergeTree.cpp:3872: DB::StorageReplicatedMergeTree::processQueueEntry(std::shared_ptr) @ 0x0000000015efc18a 23. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001624c1b2 24. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000162f9c70 25. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x00000000162fa55a 26. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc6653 27. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000000fccc4c3 28. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc3d92 29. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fcca080 30. ? @ 0x00007fbc6213eac3 31. ? @ 0x00007fbc621d0850 (version 25.3.6.10636.altinitytest (altinity build)) 2025.07.28 11:53:57.150973 [ 3971 ] {} test_13.rmt2 (7f9b740d-015c-470e-8cc6-8ba33be0dc63): auto DB::StorageReplicatedMergeTree::processQueueEntry(ReplicatedMergeTreeQueue::SelectedEntryPtr)::(anonymous class)::operator()(LogEntryPtr &) const: Code: 86. DB::HTTPException: Received error from remote server http://146b4357c08d:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Ftest%2F01165%2Ftest_13%2Frmt%2Freplicas%2F1&part=20250728_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.6.10636.altinitytest (altinity build)) '. (RECEIVED_ERROR_FROM_REMOTE_IO_SERVER), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.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 const&, int&&, String const&, unsigned long&&, String const&) @ 0x000000000feda8d9 4. /build/src/IO/HTTPCommon.cpp:104: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x000000000feda6e2 5. /build/src/IO/HTTPCommon.cpp:93: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x000000000feda537 6. /build/src/IO/ReadWriteBufferFromHTTP.cpp:277: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x000000001184a4c4 7. /build/src/IO/ReadWriteBufferFromHTTP.cpp:285: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x000000001184a615 8. /build/src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x000000001184ae59 9. /build/src/IO/ReadWriteBufferFromHTTP.cpp:472: void std::__function::__policy_invoker::__call_impl[abi:se190107]>(std::__function::__policy_storage const*) @ 0x000000001184cedd 10. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001184858b 11. /build/src/IO/ReadWriteBufferFromHTTP.cpp:465: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x000000001184bf0b 12. /build/src/IO/ReadBuffer.h:60: DB::ReadBuffer::next() @ 0x000000000a148c7b 13. /build/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) @ 0x0000000011849fb2 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]>&)>&, 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&) @ 0x0000000011841980 15. /build/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) @ 0x000000001621208e 16. /build/src/Storages/StorageReplicatedMergeTree.cpp:5228: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl[abi:se190107] const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000015f9a5fe 17. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000015ed8bfd 18. /build/src/Storages/StorageReplicatedMergeTree.cpp:2514: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x0000000015ec9aab 19. /build/src/Storages/StorageReplicatedMergeTree.cpp:2349: DB::StorageReplicatedMergeTree::executeLogEntry(DB::ReplicatedMergeTreeLogEntry&) @ 0x0000000015eba91b 20. /build/src/Storages/StorageReplicatedMergeTree.cpp:3876: bool std::__function::__policy_invoker&)>::__call_impl[abi:se190107])::$_1, bool (std::shared_ptr&)>>(std::__function::__policy_storage const*, std::shared_ptr&) @ 0x0000000015f9837e 21. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000165d6fc3 22. /build/src/Storages/StorageReplicatedMergeTree.cpp:3872: DB::StorageReplicatedMergeTree::processQueueEntry(std::shared_ptr) @ 0x0000000015efc18a 23. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001624c1b2 24. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000162f9c70 25. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x00000000162fa55a 26. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc6653 27. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000000fccc4c3 28. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc3d92 29. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fcca080 30. ? @ 0x00007fbc6213eac3 31. ? @ 0x00007fbc621d0850 (version 25.3.6.10636.altinitytest (altinity build)) 2025.07.28 11:53:57.431354 [ 3970 ] {} test_13.rmt2 (7f9b740d-015c-470e-8cc6-8ba33be0dc63): auto DB::StorageReplicatedMergeTree::processQueueEntry(ReplicatedMergeTreeQueue::SelectedEntryPtr)::(anonymous class)::operator()(LogEntryPtr &) const: Code: 86. DB::HTTPException: Received error from remote server http://146b4357c08d:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Ftest%2F01165%2Ftest_13%2Frmt%2Freplicas%2F1&part=20250728_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.6.10636.altinitytest (altinity build)) '. (RECEIVED_ERROR_FROM_REMOTE_IO_SERVER), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.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 const&, int&&, String const&, unsigned long&&, String const&) @ 0x000000000feda8d9 4. /build/src/IO/HTTPCommon.cpp:104: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x000000000feda6e2 5. /build/src/IO/HTTPCommon.cpp:93: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x000000000feda537 6. /build/src/IO/ReadWriteBufferFromHTTP.cpp:277: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x000000001184a4c4 7. /build/src/IO/ReadWriteBufferFromHTTP.cpp:285: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x000000001184a615 8. /build/src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x000000001184ae59 9. /build/src/IO/ReadWriteBufferFromHTTP.cpp:472: void std::__function::__policy_invoker::__call_impl[abi:se190107]>(std::__function::__policy_storage const*) @ 0x000000001184cedd 10. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001184858b 11. /build/src/IO/ReadWriteBufferFromHTTP.cpp:465: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x000000001184bf0b 12. /build/src/IO/ReadBuffer.h:60: DB::ReadBuffer::next() @ 0x000000000a148c7b 13. /build/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) @ 0x0000000011849fb2 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]>&)>&, 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&) @ 0x0000000011841980 15. /build/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) @ 0x000000001621208e 16. /build/src/Storages/StorageReplicatedMergeTree.cpp:5228: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl[abi:se190107] const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000015f9a5fe 17. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000015ed8bfd 18. /build/src/Storages/StorageReplicatedMergeTree.cpp:2514: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x0000000015ec9aab 19. /build/src/Storages/StorageReplicatedMergeTree.cpp:2349: DB::StorageReplicatedMergeTree::executeLogEntry(DB::ReplicatedMergeTreeLogEntry&) @ 0x0000000015eba91b 20. /build/src/Storages/StorageReplicatedMergeTree.cpp:3876: bool std::__function::__policy_invoker&)>::__call_impl[abi:se190107])::$_1, bool (std::shared_ptr&)>>(std::__function::__policy_storage const*, std::shared_ptr&) @ 0x0000000015f9837e 21. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000165d6fc3 22. /build/src/Storages/StorageReplicatedMergeTree.cpp:3872: DB::StorageReplicatedMergeTree::processQueueEntry(std::shared_ptr) @ 0x0000000015efc18a 23. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001624c1b2 24. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000162f9c70 25. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x00000000162fa55a 26. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc6653 27. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000000fccc4c3 28. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc3d92 29. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fcca080 30. ? @ 0x00007fbc6213eac3 31. ? @ 0x00007fbc621d0850 (version 25.3.6.10636.altinitytest (altinity build)) 2025.07.28 11:53:57.561933 [ 17371 ] {52cc5515-4fea-4f6a-91a8-9b9191cdf3c2} executeQuery: Code: 100. DB::Exception: Unknown packet 9223372036854775807 from server 127.0.0.2:9000: While executing Remote. (UNKNOWN_PACKET_FROM_SERVER) (version 25.3.6.10636.altinitytest (altinity build)) (from [::1]:60456) (comment: 01822_async_read_from_socket_crash.sh) (query 1, line 1) (in query: select number from remote('127.0.0.{2,3}', numbers(20)) limit 8 settings max_block_size = 2, unknown_packet_in_send_data=4, sleep_in_send_data_ms=100, async_socket_for_remote=1 format Null), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String const&) @ 0x000000000a68756b 4. /build/src/Client/Connection.cpp:1323: DB::Connection::receivePacket() @ 0x00000000167db7d2 5. /build/src/Client/PacketReceiver.cpp:66: DB::PacketReceiver::Task::run(std::function, std::function) @ 0x0000000016819393 6. /build/src/Common/AsyncTaskExecutor.cpp:89: DB::AsyncTaskExecutor::Routine::operator()(std::function) @ 0x0000000013bd1892 7. /build/src/Common/Fiber.h:76: boost::context::detail::fiber_record>::run(void*) @ 0x0000000013bd16fa 8. /build/contrib/boost/boost/context/fiber_fcontext.hpp:97: void boost::context::detail::fiber_entry>>(boost::context::detail::transfer_t) @ 0x0000000013bd1621 2025.07.28 11:53:57.561892 [ 17203 ] {f992984f-20ab-4631-b548-82629e68d751} executeQuery: Code: 236. DB::NetException: Client has dropped the connection, cancel the query. (ABORTED) (version 25.3.6.10636.altinitytest (altinity build)) (from [::ffff:127.0.0.1]:41026) (comment: 01822_async_read_from_socket_crash.sh) (query 1, line 1) (in query: SELECT `__table1`.`number` AS `number` FROM numbers(20) AS `__table1` LIMIT _CAST(8, 'UInt64')), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::NetException::NetException(int, T&&) @ 0x0000000016900f80 3. /build/src/Server/TCPHandler.cpp:2426: DB::TCPHandler::receivePacketsExpectCancel(DB::QueryState&) @ 0x00000000168fba18 4. /build/src/Server/TCPHandler.cpp:1242: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x00000000168f1540 5. /build/src/Server/TCPHandler.cpp:678: DB::TCPHandler::runImpl() @ 0x00000000168e68e5 6. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 7. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 8. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 9. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 10. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 11. ? @ 0x00007fbc6213eac3 12. ? @ 0x00007fbc621d0850 2025.07.28 11:53:57.568746 [ 17203 ] {f992984f-20ab-4631-b548-82629e68d751} 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]:41026). (NETWORK_ERROR), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::NetException::NetException(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&) @ 0x000000000fd50fb5 3. /build/src/IO/WriteBufferFromPocoSocket.cpp:171: DB::WriteBufferFromPocoSocket::nextImpl() @ 0x000000000fd525a7 4. /build/src/IO/WriteBuffer.h:53: DB::WriteBuffer::next() @ 0x000000000a0755be 5. /build/src/Server/TCPHandler.cpp:2620: DB::TCPHandler::sendLogs(DB::QueryState&) @ 0x00000000168f1e17 6. /build/src/Server/TCPHandler.cpp:821: DB::TCPHandler::runImpl() @ 0x00000000168e6c63 7. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 8. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 9. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 10. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 11. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 12. ? @ 0x00007fbc6213eac3 13. ? @ 0x00007fbc621d0850 (version 25.3.6.10636.altinitytest (altinity build)) 2025.07.28 11:53:57.578414 [ 17203 ] {} 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. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::NetException::NetException(int, T&&) @ 0x0000000016900f80 3. /build/src/Server/TCPHandler.cpp:2426: DB::TCPHandler::receivePacketsExpectCancel(DB::QueryState&) @ 0x00000000168fba18 4. /build/src/Server/TCPHandler.cpp:1242: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x00000000168f1540 5. /build/src/Server/TCPHandler.cpp:678: DB::TCPHandler::runImpl() @ 0x00000000168e68e5 6. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 7. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 8. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 9. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 10. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 11. ? @ 0x00007fbc6213eac3 12. ? @ 0x00007fbc621d0850 2025.07.28 11:53:57.580011 [ 17371 ] {} TCPHandler: Code: 100. DB::Exception: Unknown packet 9223372036854775807 from server 127.0.0.2:9000: While executing Remote. (UNKNOWN_PACKET_FROM_SERVER), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String const&) @ 0x000000000a68756b 4. /build/src/Client/Connection.cpp:1323: DB::Connection::receivePacket() @ 0x00000000167db7d2 5. /build/src/Client/PacketReceiver.cpp:66: DB::PacketReceiver::Task::run(std::function, std::function) @ 0x0000000016819393 6. /build/src/Common/AsyncTaskExecutor.cpp:89: DB::AsyncTaskExecutor::Routine::operator()(std::function) @ 0x0000000013bd1892 7. /build/src/Common/Fiber.h:76: boost::context::detail::fiber_record>::run(void*) @ 0x0000000013bd16fa 8. /build/contrib/boost/boost/context/fiber_fcontext.hpp:97: void boost::context::detail::fiber_entry>>(boost::context::detail::transfer_t) @ 0x0000000013bd1621 Job's origin stack trace: 0. /build/src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000000fc33b84 1. /build/src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000000fcc2ea7 2. /build/src/Common/ThreadPool.cpp:401: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fcc7f1c 3. /build/src/Common/ThreadPool.cpp:494: ThreadPoolImpl>::scheduleOrThrowOnError(std::function, Priority) @ 0x000000000fcc7a0e 4. /build/src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::spawnThreadsImpl() @ 0x00000000169b2c0c 5. /build/src/Processors/Executors/PipelineExecutor.cpp:394: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x00000000169b0ba7 6. /build/src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x00000000169b03f4 7. /build/src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:se190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169bfeab 8. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc3d92 9. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fcca080 10. ? @ 0x00007fbc6213eac3 11. ? @ 0x00007fbc621d0850 Job's origin stack trace: 0. /build/src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000000fc33b84 1. /build/src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000000fcc2ea7 2. /build/src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fcc535c 3. /build/src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000000fcc584d 4. /build/src/Common/ThreadPool.h:279: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x00000000169bf193 5. /build/src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x00000000169bf518 6. /build/src/Server/TCPHandler.cpp:1237: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x00000000168f1525 7. /build/src/Server/TCPHandler.cpp:678: DB::TCPHandler::runImpl() @ 0x00000000168e68e5 8. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 9. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 10. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 11. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 12. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 13. ? @ 0x00007fbc6213eac3 14. ? @ 0x00007fbc621d0850 2025.07.28 11:53:57.616521 [ 17208 ] {c50b4fa8-d630-48f7-92c1-ab66a7987c7c} 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]:59994). (NETWORK_ERROR), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::NetException::NetException(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&) @ 0x000000000fd50fb5 3. /build/src/IO/WriteBufferFromPocoSocket.cpp:160: DB::WriteBufferFromPocoSocket::nextImpl() @ 0x000000000fd523f1 4. /build/src/IO/WriteBuffer.h:53: DB::WriteBuffer::next() @ 0x000000000a0755be 5. /build/src/Server/TCPHandler.cpp:2490: DB::TCPHandler::sendData(DB::QueryState&, DB::Block const&) @ 0x00000000168fa306 6. /build/src/Server/TCPHandler.cpp:1266: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x00000000168f162c 7. /build/src/Server/TCPHandler.cpp:678: DB::TCPHandler::runImpl() @ 0x00000000168e68e5 8. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 9. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 10. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 11. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 12. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 13. ? @ 0x00007fbc6213eac3 14. ? @ 0x00007fbc621d0850 (version 25.3.6.10636.altinitytest (altinity build)) 2025.07.28 11:53:57.619913 [ 17208 ] {c50b4fa8-d630-48f7-92c1-ab66a7987c7c} executeQuery: Code: 210. DB::NetException: Connection reset by peer, while writing to socket ([::ffff:127.0.0.3]:9000 -> [::ffff:127.0.0.1]:59994). (NETWORK_ERROR) (version 25.3.6.10636.altinitytest (altinity build)) (from [::ffff:127.0.0.1]:59994) (comment: 01822_async_read_from_socket_crash.sh) (query 1, line 1) (in query: SELECT `__table1`.`number` AS `number` FROM numbers(20) AS `__table1` LIMIT _CAST(8, 'UInt64')), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::NetException::NetException(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&) @ 0x000000000fd50fb5 3. /build/src/IO/WriteBufferFromPocoSocket.cpp:160: DB::WriteBufferFromPocoSocket::nextImpl() @ 0x000000000fd523f1 4. /build/src/IO/WriteBuffer.h:53: DB::WriteBuffer::next() @ 0x000000000a0755be 5. /build/src/Server/TCPHandler.cpp:2490: DB::TCPHandler::sendData(DB::QueryState&, DB::Block const&) @ 0x00000000168fa306 6. /build/src/Server/TCPHandler.cpp:1266: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x00000000168f162c 7. /build/src/Server/TCPHandler.cpp:678: DB::TCPHandler::runImpl() @ 0x00000000168e68e5 8. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 9. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 10. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 11. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 12. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 13. ? @ 0x00007fbc6213eac3 14. ? @ 0x00007fbc621d0850 2025.07.28 11:53:57.623099 [ 17208 ] {} TCPHandler: Code: 210. DB::NetException: Connection reset by peer, while writing to socket ([::ffff:127.0.0.3]:9000 -> [::ffff:127.0.0.1]:59994). (NETWORK_ERROR), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::NetException::NetException(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&) @ 0x000000000fd50fb5 3. /build/src/IO/WriteBufferFromPocoSocket.cpp:160: DB::WriteBufferFromPocoSocket::nextImpl() @ 0x000000000fd523f1 4. /build/src/IO/WriteBuffer.h:53: DB::WriteBuffer::next() @ 0x000000000a0755be 5. /build/src/Server/TCPHandler.cpp:2490: DB::TCPHandler::sendData(DB::QueryState&, DB::Block const&) @ 0x00000000168fa306 6. /build/src/Server/TCPHandler.cpp:1266: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x00000000168f162c 7. /build/src/Server/TCPHandler.cpp:678: DB::TCPHandler::runImpl() @ 0x00000000168e68e5 8. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 9. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 10. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 11. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 12. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 13. ? @ 0x00007fbc6213eac3 14. ? @ 0x00007fbc621d0850 2025.07.28 11:53:57.848460 [ 3965 ] {} test_13.rmt2 (7f9b740d-015c-470e-8cc6-8ba33be0dc63): auto DB::StorageReplicatedMergeTree::processQueueEntry(ReplicatedMergeTreeQueue::SelectedEntryPtr)::(anonymous class)::operator()(LogEntryPtr &) const: Code: 86. DB::HTTPException: Received error from remote server http://146b4357c08d:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Ftest%2F01165%2Ftest_13%2Frmt%2Freplicas%2F1&part=20250728_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.6.10636.altinitytest (altinity build)) '. (RECEIVED_ERROR_FROM_REMOTE_IO_SERVER), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.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 const&, int&&, String const&, unsigned long&&, String const&) @ 0x000000000feda8d9 4. /build/src/IO/HTTPCommon.cpp:104: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x000000000feda6e2 5. /build/src/IO/HTTPCommon.cpp:93: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x000000000feda537 6. /build/src/IO/ReadWriteBufferFromHTTP.cpp:277: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x000000001184a4c4 7. /build/src/IO/ReadWriteBufferFromHTTP.cpp:285: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x000000001184a615 8. /build/src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x000000001184ae59 9. /build/src/IO/ReadWriteBufferFromHTTP.cpp:472: void std::__function::__policy_invoker::__call_impl[abi:se190107]>(std::__function::__policy_storage const*) @ 0x000000001184cedd 10. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001184858b 11. /build/src/IO/ReadWriteBufferFromHTTP.cpp:465: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x000000001184bf0b 12. /build/src/IO/ReadBuffer.h:60: DB::ReadBuffer::next() @ 0x000000000a148c7b 13. /build/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) @ 0x0000000011849fb2 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]>&)>&, 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&) @ 0x0000000011841980 15. /build/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) @ 0x000000001621208e 16. /build/src/Storages/StorageReplicatedMergeTree.cpp:5228: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl[abi:se190107] const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000015f9a5fe 17. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000015ed8bfd 18. /build/src/Storages/StorageReplicatedMergeTree.cpp:2514: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x0000000015ec9aab 19. /build/src/Storages/StorageReplicatedMergeTree.cpp:2349: DB::StorageReplicatedMergeTree::executeLogEntry(DB::ReplicatedMergeTreeLogEntry&) @ 0x0000000015eba91b 20. /build/src/Storages/StorageReplicatedMergeTree.cpp:3876: bool std::__function::__policy_invoker&)>::__call_impl[abi:se190107])::$_1, bool (std::shared_ptr&)>>(std::__function::__policy_storage const*, std::shared_ptr&) @ 0x0000000015f9837e 21. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000165d6fc3 22. /build/src/Storages/StorageReplicatedMergeTree.cpp:3872: DB::StorageReplicatedMergeTree::processQueueEntry(std::shared_ptr) @ 0x0000000015efc18a 23. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001624c1b2 24. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000162f9c70 25. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x00000000162fa55a 26. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc6653 27. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000000fccc4c3 28. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc3d92 29. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fcca080 30. ? @ 0x00007fbc6213eac3 31. ? @ 0x00007fbc621d0850 (version 25.3.6.10636.altinitytest (altinity build)) 2025.07.28 11:53:58.360545 [ 17371 ] {e17976ec-fa3e-494a-b2b0-a561ef3cc177} executeQuery: Code: 100. DB::Exception: Unknown packet 9223372036854775807 from server 127.0.0.2:9000: While executing Remote. (UNKNOWN_PACKET_FROM_SERVER) (version 25.3.6.10636.altinitytest (altinity build)) (from [::1]:60502) (comment: 01822_async_read_from_socket_crash.sh) (query 1, line 1) (in query: select number from remote('127.0.0.{2,3}', numbers(20)) limit 8 settings max_block_size = 2, unknown_packet_in_send_data=4, sleep_in_send_data_ms=100, async_socket_for_remote=1 format Null), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String const&) @ 0x000000000a68756b 4. /build/src/Client/Connection.cpp:1323: DB::Connection::receivePacket() @ 0x00000000167db7d2 5. /build/src/Client/PacketReceiver.cpp:66: DB::PacketReceiver::Task::run(std::function, std::function) @ 0x0000000016819393 6. /build/src/Common/AsyncTaskExecutor.cpp:89: DB::AsyncTaskExecutor::Routine::operator()(std::function) @ 0x0000000013bd1892 7. /build/src/Common/Fiber.h:76: boost::context::detail::fiber_record>::run(void*) @ 0x0000000013bd16fa 8. /build/contrib/boost/boost/context/fiber_fcontext.hpp:97: void boost::context::detail::fiber_entry>>(boost::context::detail::transfer_t) @ 0x0000000013bd1621 2025.07.28 11:53:58.365547 [ 5327 ] {5519f5d4-3ca1-4e37-a43c-59f6b0d08e44} 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.6.10636.altinitytest (altinity build)) (from [::1]:60514) (comment: 02377_majority_insert_quorum_zookeeper_long.sql) (query 6, line 15) (in query: CREATE TABLE quorum1 (`x` UInt32, `y` Date) ENGINE = ReplicatedMergeTree('/clickhouse/tables/{database}/test_02377/quorum', '1') PARTITION BY y ORDER BY x SETTINGS index_granularity = 52269, min_bytes_for_wide_part = 0, ratio_of_defaults_for_sparse_serialization = 0., replace_long_file_name_to_hash = true, max_file_name_length = 11, min_bytes_for_full_part_storage = 536870912, compact_parts_max_bytes_to_buffer = 159606798, compact_parts_max_granules_to_buffer = 235, compact_parts_merge_max_bytes_to_prefetch_part = 16237744, merge_max_block_size = 22109, old_parts_lifetime = 480., prefer_fetch_merged_part_size_threshold = 10737418240, vertical_merge_algorithm_min_rows_to_activate = 173637, vertical_merge_algorithm_min_columns_to_activate = 100, min_merge_bytes_to_use_direct_io = 10737418240, index_granularity_bytes = 13040001, 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 = false, enable_block_offset_column = false, cache_populated_by_fetch = true, marks_compress_block_size = 15165, primary_key_compress_block_size = 89000, 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. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000000a074fcb 4. /build/src/Databases/DatabaseReplicated.cpp:959: DB::DatabaseReplicated::checkTableEngine(DB::ASTCreateQuery const&, DB::ASTStorage&, std::shared_ptr) const @ 0x0000000013d9cf56 5. /build/src/Databases/DatabaseReplicated.cpp:1083: DB::DatabaseReplicated::checkQueryValid(std::shared_ptr const&, std::shared_ptr) const @ 0x0000000013d9ebb5 6. /build/src/Databases/DatabaseReplicated.cpp:1130: DB::DatabaseReplicated::tryEnqueueReplicatedDDL(std::shared_ptr const&, std::shared_ptr, DB::QueryFlags) @ 0x0000000013d9f10b 7. /build/src/Interpreters/InterpreterCreateQuery.cpp:1723: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000148f96f8 8. /build/src/Interpreters/InterpreterCreateQuery.cpp:2352: DB::InterpreterCreateQuery::execute() @ 0x0000000014905a41 9. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88dc9 10. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 11. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 12. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 13. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 14. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 16. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 17. ? @ 0x00007fbc6213eac3 18. ? @ 0x00007fbc621d0850 2025.07.28 11:53:58.391246 [ 5327 ] {} 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. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000000a074fcb 4. /build/src/Databases/DatabaseReplicated.cpp:959: DB::DatabaseReplicated::checkTableEngine(DB::ASTCreateQuery const&, DB::ASTStorage&, std::shared_ptr) const @ 0x0000000013d9cf56 5. /build/src/Databases/DatabaseReplicated.cpp:1083: DB::DatabaseReplicated::checkQueryValid(std::shared_ptr const&, std::shared_ptr) const @ 0x0000000013d9ebb5 6. /build/src/Databases/DatabaseReplicated.cpp:1130: DB::DatabaseReplicated::tryEnqueueReplicatedDDL(std::shared_ptr const&, std::shared_ptr, DB::QueryFlags) @ 0x0000000013d9f10b 7. /build/src/Interpreters/InterpreterCreateQuery.cpp:1723: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000148f96f8 8. /build/src/Interpreters/InterpreterCreateQuery.cpp:2352: DB::InterpreterCreateQuery::execute() @ 0x0000000014905a41 9. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88dc9 10. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 11. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 12. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 13. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 14. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 16. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 17. ? @ 0x00007fbc6213eac3 18. ? @ 0x00007fbc621d0850 2025.07.28 11:53:58.393898 [ 17371 ] {} TCPHandler: Code: 100. DB::Exception: Unknown packet 9223372036854775807 from server 127.0.0.2:9000: While executing Remote. (UNKNOWN_PACKET_FROM_SERVER), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String const&) @ 0x000000000a68756b 4. /build/src/Client/Connection.cpp:1323: DB::Connection::receivePacket() @ 0x00000000167db7d2 5. /build/src/Client/PacketReceiver.cpp:66: DB::PacketReceiver::Task::run(std::function, std::function) @ 0x0000000016819393 6. /build/src/Common/AsyncTaskExecutor.cpp:89: DB::AsyncTaskExecutor::Routine::operator()(std::function) @ 0x0000000013bd1892 7. /build/src/Common/Fiber.h:76: boost::context::detail::fiber_record>::run(void*) @ 0x0000000013bd16fa 8. /build/contrib/boost/boost/context/fiber_fcontext.hpp:97: void boost::context::detail::fiber_entry>>(boost::context::detail::transfer_t) @ 0x0000000013bd1621 Job's origin stack trace: 0. /build/src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000000fc33b84 1. /build/src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000000fcc2ea7 2. /build/src/Common/ThreadPool.cpp:401: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fcc7f1c 3. /build/src/Common/ThreadPool.cpp:494: ThreadPoolImpl>::scheduleOrThrowOnError(std::function, Priority) @ 0x000000000fcc7a0e 4. /build/src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::spawnThreadsImpl() @ 0x00000000169b2c0c 5. /build/src/Processors/Executors/PipelineExecutor.cpp:394: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x00000000169b0ba7 6. /build/src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x00000000169b03f4 7. /build/src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:se190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169bfeab 8. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc3d92 9. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fcca080 10. ? @ 0x00007fbc6213eac3 11. ? @ 0x00007fbc621d0850 Job's origin stack trace: 0. /build/src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000000fc33b84 1. /build/src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000000fcc2ea7 2. /build/src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fcc535c 3. /build/src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000000fcc584d 4. /build/src/Common/ThreadPool.h:279: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x00000000169bf193 5. /build/src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x00000000169bf518 6. /build/src/Server/TCPHandler.cpp:1237: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x00000000168f1525 7. /build/src/Server/TCPHandler.cpp:678: DB::TCPHandler::runImpl() @ 0x00000000168e68e5 8. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 9. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 10. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 11. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 12. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 13. ? @ 0x00007fbc6213eac3 14. ? @ 0x00007fbc621d0850 2025.07.28 11:53:58.407288 [ 17203 ] {8e0bb1bb-ec45-4709-bc6d-97f6c5ddedd1} executeQuery: Code: 236. DB::NetException: Client has dropped the connection, cancel the query. (ABORTED) (version 25.3.6.10636.altinitytest (altinity build)) (from [::ffff:127.0.0.1]:41040) (comment: 01822_async_read_from_socket_crash.sh) (query 1, line 1) (in query: SELECT `__table1`.`number` AS `number` FROM numbers(20) AS `__table1` LIMIT _CAST(8, 'UInt64')), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::NetException::NetException(int, T&&) @ 0x0000000016900f80 3. /build/src/Server/TCPHandler.cpp:2426: DB::TCPHandler::receivePacketsExpectCancel(DB::QueryState&) @ 0x00000000168fba18 4. /build/src/Server/TCPHandler.cpp:1242: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x00000000168f1540 5. /build/src/Server/TCPHandler.cpp:678: DB::TCPHandler::runImpl() @ 0x00000000168e68e5 6. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 7. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 8. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 9. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 10. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 11. ? @ 0x00007fbc6213eac3 12. ? @ 0x00007fbc621d0850 2025.07.28 11:53:58.409113 [ 17203 ] {8e0bb1bb-ec45-4709-bc6d-97f6c5ddedd1} 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]:41040). (NETWORK_ERROR), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::NetException::NetException(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&) @ 0x000000000fd50fb5 3. /build/src/IO/WriteBufferFromPocoSocket.cpp:171: DB::WriteBufferFromPocoSocket::nextImpl() @ 0x000000000fd525a7 4. /build/src/IO/WriteBuffer.h:53: DB::WriteBuffer::next() @ 0x000000000a0755be 5. /build/src/Server/TCPHandler.cpp:2620: DB::TCPHandler::sendLogs(DB::QueryState&) @ 0x00000000168f1e17 6. /build/src/Server/TCPHandler.cpp:821: DB::TCPHandler::runImpl() @ 0x00000000168e6c63 7. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 8. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 9. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 10. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 11. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 12. ? @ 0x00007fbc6213eac3 13. ? @ 0x00007fbc621d0850 (version 25.3.6.10636.altinitytest (altinity build)) 2025.07.28 11:53:58.411103 [ 17203 ] {} 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. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::NetException::NetException(int, T&&) @ 0x0000000016900f80 3. /build/src/Server/TCPHandler.cpp:2426: DB::TCPHandler::receivePacketsExpectCancel(DB::QueryState&) @ 0x00000000168fba18 4. /build/src/Server/TCPHandler.cpp:1242: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x00000000168f1540 5. /build/src/Server/TCPHandler.cpp:678: DB::TCPHandler::runImpl() @ 0x00000000168e68e5 6. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 7. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 8. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 9. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 10. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 11. ? @ 0x00007fbc6213eac3 12. ? @ 0x00007fbc621d0850 2025.07.28 11:53:58.414517 [ 5951 ] {90105d2b-2aa9-4dd4-aec4-5ad7a9ce590b} 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]:60004). (NETWORK_ERROR), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::NetException::NetException(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&) @ 0x000000000fd50fb5 3. /build/src/IO/WriteBufferFromPocoSocket.cpp:171: DB::WriteBufferFromPocoSocket::nextImpl() @ 0x000000000fd525a7 4. /build/src/IO/WriteBuffer.h:53: DB::WriteBuffer::next() @ 0x000000000a0755be 5. /build/src/Server/TCPHandler.cpp:824: DB::TCPHandler::runImpl() @ 0x00000000168e6c86 6. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 7. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 8. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 9. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 10. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 11. ? @ 0x00007fbc6213eac3 12. ? @ 0x00007fbc621d0850 (version 25.3.6.10636.altinitytest (altinity build)) 2025.07.28 11:53:58.714612 [ 3961 ] {} test_13.rmt2 (7f9b740d-015c-470e-8cc6-8ba33be0dc63): auto DB::StorageReplicatedMergeTree::processQueueEntry(ReplicatedMergeTreeQueue::SelectedEntryPtr)::(anonymous class)::operator()(LogEntryPtr &) const: Code: 86. DB::HTTPException: Received error from remote server http://146b4357c08d:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Ftest%2F01165%2Ftest_13%2Frmt%2Freplicas%2F1&part=20250728_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.6.10636.altinitytest (altinity build)) '. (RECEIVED_ERROR_FROM_REMOTE_IO_SERVER), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.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 const&, int&&, String const&, unsigned long&&, String const&) @ 0x000000000feda8d9 4. /build/src/IO/HTTPCommon.cpp:104: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x000000000feda6e2 5. /build/src/IO/HTTPCommon.cpp:93: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x000000000feda537 6. /build/src/IO/ReadWriteBufferFromHTTP.cpp:277: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x000000001184a4c4 7. /build/src/IO/ReadWriteBufferFromHTTP.cpp:285: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x000000001184a615 8. /build/src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x000000001184ae59 9. /build/src/IO/ReadWriteBufferFromHTTP.cpp:472: void std::__function::__policy_invoker::__call_impl[abi:se190107]>(std::__function::__policy_storage const*) @ 0x000000001184cedd 10. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001184858b 11. /build/src/IO/ReadWriteBufferFromHTTP.cpp:465: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x000000001184bf0b 12. /build/src/IO/ReadBuffer.h:60: DB::ReadBuffer::next() @ 0x000000000a148c7b 13. /build/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) @ 0x0000000011849fb2 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]>&)>&, 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&) @ 0x0000000011841980 15. /build/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) @ 0x000000001621208e 16. /build/src/Storages/StorageReplicatedMergeTree.cpp:5228: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl[abi:se190107] const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000015f9a5fe 17. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000015ed8bfd 18. /build/src/Storages/StorageReplicatedMergeTree.cpp:2514: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x0000000015ec9aab 19. /build/src/Storages/StorageReplicatedMergeTree.cpp:2349: DB::StorageReplicatedMergeTree::executeLogEntry(DB::ReplicatedMergeTreeLogEntry&) @ 0x0000000015eba91b 20. /build/src/Storages/StorageReplicatedMergeTree.cpp:3876: bool std::__function::__policy_invoker&)>::__call_impl[abi:se190107])::$_1, bool (std::shared_ptr&)>>(std::__function::__policy_storage const*, std::shared_ptr&) @ 0x0000000015f9837e 21. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000165d6fc3 22. /build/src/Storages/StorageReplicatedMergeTree.cpp:3872: DB::StorageReplicatedMergeTree::processQueueEntry(std::shared_ptr) @ 0x0000000015efc18a 23. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001624c1b2 24. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000162f9c70 25. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x00000000162fa55a 26. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc6653 27. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000000fccc4c3 28. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc3d92 29. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fcca080 30. ? @ 0x00007fbc6213eac3 31. ? @ 0x00007fbc621d0850 (version 25.3.6.10636.altinitytest (altinity build)) 2025.07.28 11:53:59.276270 [ 17208 ] {6f456903-a4a2-406f-bccb-865b45ee7cf3} executeQuery: Code: 236. DB::NetException: Client has dropped the connection, cancel the query. (ABORTED) (version 25.3.6.10636.altinitytest (altinity build)) (from [::ffff:127.0.0.1]:41048) (comment: 01822_async_read_from_socket_crash.sh) (query 1, line 1) (in query: SELECT `__table1`.`number` AS `number` FROM numbers(20) AS `__table1` LIMIT _CAST(8, 'UInt64')), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::NetException::NetException(int, T&&) @ 0x0000000016900f80 3. /build/src/Server/TCPHandler.cpp:2426: DB::TCPHandler::receivePacketsExpectCancel(DB::QueryState&) @ 0x00000000168fba18 4. /build/src/Server/TCPHandler.cpp:1242: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x00000000168f1540 5. /build/src/Server/TCPHandler.cpp:678: DB::TCPHandler::runImpl() @ 0x00000000168e68e5 6. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 7. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 8. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 9. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 10. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 11. ? @ 0x00007fbc6213eac3 12. ? @ 0x00007fbc621d0850 2025.07.28 11:53:59.281227 [ 17203 ] {39f5e1d5-b0e1-459c-b554-bfc06f343480} executeQuery: Code: 100. DB::Exception: Unknown packet 9223372036854775807 from server 127.0.0.2:9000: While executing Remote. (UNKNOWN_PACKET_FROM_SERVER) (version 25.3.6.10636.altinitytest (altinity build)) (from [::1]:60532) (comment: 01822_async_read_from_socket_crash.sh) (query 1, line 1) (in query: select number from remote('127.0.0.{2,3}', numbers(20)) limit 8 settings max_block_size = 2, unknown_packet_in_send_data=4, sleep_in_send_data_ms=100, async_socket_for_remote=1 format Null), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String const&) @ 0x000000000a68756b 4. /build/src/Client/Connection.cpp:1323: DB::Connection::receivePacket() @ 0x00000000167db7d2 5. /build/src/Client/PacketReceiver.cpp:66: DB::PacketReceiver::Task::run(std::function, std::function) @ 0x0000000016819393 6. /build/src/Common/AsyncTaskExecutor.cpp:89: DB::AsyncTaskExecutor::Routine::operator()(std::function) @ 0x0000000013bd1892 7. /build/src/Common/Fiber.h:76: boost::context::detail::fiber_record>::run(void*) @ 0x0000000013bd16fa 8. /build/contrib/boost/boost/context/fiber_fcontext.hpp:97: void boost::context::detail::fiber_entry>>(boost::context::detail::transfer_t) @ 0x0000000013bd1621 2025.07.28 11:53:59.281316 [ 17208 ] {6f456903-a4a2-406f-bccb-865b45ee7cf3} 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]:41048). (NETWORK_ERROR), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::NetException::NetException(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&) @ 0x000000000fd50fb5 3. /build/src/IO/WriteBufferFromPocoSocket.cpp:171: DB::WriteBufferFromPocoSocket::nextImpl() @ 0x000000000fd525a7 4. /build/src/IO/WriteBuffer.h:53: DB::WriteBuffer::next() @ 0x000000000a0755be 5. /build/src/Server/TCPHandler.cpp:2620: DB::TCPHandler::sendLogs(DB::QueryState&) @ 0x00000000168f1e17 6. /build/src/Server/TCPHandler.cpp:821: DB::TCPHandler::runImpl() @ 0x00000000168e6c63 7. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 8. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 9. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 10. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 11. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 12. ? @ 0x00007fbc6213eac3 13. ? @ 0x00007fbc621d0850 (version 25.3.6.10636.altinitytest (altinity build)) 2025.07.28 11:53:59.286956 [ 17208 ] {} 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. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::NetException::NetException(int, T&&) @ 0x0000000016900f80 3. /build/src/Server/TCPHandler.cpp:2426: DB::TCPHandler::receivePacketsExpectCancel(DB::QueryState&) @ 0x00000000168fba18 4. /build/src/Server/TCPHandler.cpp:1242: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x00000000168f1540 5. /build/src/Server/TCPHandler.cpp:678: DB::TCPHandler::runImpl() @ 0x00000000168e68e5 6. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 7. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 8. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 9. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 10. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 11. ? @ 0x00007fbc6213eac3 12. ? @ 0x00007fbc621d0850 2025.07.28 11:53:59.297969 [ 5951 ] {} 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. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception>&, String>(int, FormatStringHelperImpl>&>::type, std::type_identity::type>, std::basic_string_view>&, String&&) @ 0x000000001385a5eb 4. /build/src/Access/SettingsConstraints.cpp:376: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000013859b18 5. /build/src/Access/SettingsConstraints.cpp:300: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000013858faf 6. /build/src/Access/SettingsConstraints.cpp:209: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000013859223 7. /build/src/Interpreters/Context.cpp:2690: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000014436134 8. /build/src/Interpreters/Context.cpp:2729: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x000000001443662b 9. /build/src/Server/HTTPHandler.cpp:457: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000001686d165 10. /build/src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x0000000016870807 11. /build/src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x0000000016907e99 12. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 13. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 14. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 15. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 16. ? @ 0x00007fbc6213eac3 17. ? @ 0x00007fbc621d0850 (version 25.3.6.10636.altinitytest (altinity build)) 2025.07.28 11:53:59.335356 [ 17232 ] {d244719d-76ed-4ddc-a799-d8af0c72e12c} 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]:60006). (NETWORK_ERROR), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::NetException::NetException(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&) @ 0x000000000fd50fb5 3. /build/src/IO/WriteBufferFromPocoSocket.cpp:160: DB::WriteBufferFromPocoSocket::nextImpl() @ 0x000000000fd523f1 4. /build/src/IO/WriteBuffer.h:53: DB::WriteBuffer::next() @ 0x000000000a0755be 5. /build/src/Server/TCPHandler.cpp:2490: DB::TCPHandler::sendData(DB::QueryState&, DB::Block const&) @ 0x00000000168fa306 6. /build/src/Server/TCPHandler.cpp:1266: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x00000000168f162c 7. /build/src/Server/TCPHandler.cpp:678: DB::TCPHandler::runImpl() @ 0x00000000168e68e5 8. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 9. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 10. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 11. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 12. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 13. ? @ 0x00007fbc6213eac3 14. ? @ 0x00007fbc621d0850 (version 25.3.6.10636.altinitytest (altinity build)) 2025.07.28 11:53:59.347159 [ 17232 ] {d244719d-76ed-4ddc-a799-d8af0c72e12c} executeQuery: Code: 210. DB::NetException: Connection reset by peer, while writing to socket ([::ffff:127.0.0.3]:9000 -> [::ffff:127.0.0.1]:60006). (NETWORK_ERROR) (version 25.3.6.10636.altinitytest (altinity build)) (from [::ffff:127.0.0.1]:60006) (comment: 01822_async_read_from_socket_crash.sh) (query 1, line 1) (in query: SELECT `__table1`.`number` AS `number` FROM numbers(20) AS `__table1` LIMIT _CAST(8, 'UInt64')), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::NetException::NetException(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&) @ 0x000000000fd50fb5 3. /build/src/IO/WriteBufferFromPocoSocket.cpp:160: DB::WriteBufferFromPocoSocket::nextImpl() @ 0x000000000fd523f1 4. /build/src/IO/WriteBuffer.h:53: DB::WriteBuffer::next() @ 0x000000000a0755be 5. /build/src/Server/TCPHandler.cpp:2490: DB::TCPHandler::sendData(DB::QueryState&, DB::Block const&) @ 0x00000000168fa306 6. /build/src/Server/TCPHandler.cpp:1266: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x00000000168f162c 7. /build/src/Server/TCPHandler.cpp:678: DB::TCPHandler::runImpl() @ 0x00000000168e68e5 8. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 9. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 10. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 11. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 12. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 13. ? @ 0x00007fbc6213eac3 14. ? @ 0x00007fbc621d0850 2025.07.28 11:53:59.350553 [ 17232 ] {} TCPHandler: Code: 210. DB::NetException: Connection reset by peer, while writing to socket ([::ffff:127.0.0.3]:9000 -> [::ffff:127.0.0.1]:60006). (NETWORK_ERROR), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::NetException::NetException(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&) @ 0x000000000fd50fb5 3. /build/src/IO/WriteBufferFromPocoSocket.cpp:160: DB::WriteBufferFromPocoSocket::nextImpl() @ 0x000000000fd523f1 4. /build/src/IO/WriteBuffer.h:53: DB::WriteBuffer::next() @ 0x000000000a0755be 5. /build/src/Server/TCPHandler.cpp:2490: DB::TCPHandler::sendData(DB::QueryState&, DB::Block const&) @ 0x00000000168fa306 6. /build/src/Server/TCPHandler.cpp:1266: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x00000000168f162c 7. /build/src/Server/TCPHandler.cpp:678: DB::TCPHandler::runImpl() @ 0x00000000168e68e5 8. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 9. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 10. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 11. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 12. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 13. ? @ 0x00007fbc6213eac3 14. ? @ 0x00007fbc621d0850 2025.07.28 11:53:59.353755 [ 17203 ] {} TCPHandler: Code: 100. DB::Exception: Unknown packet 9223372036854775807 from server 127.0.0.2:9000: While executing Remote. (UNKNOWN_PACKET_FROM_SERVER), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String const&) @ 0x000000000a68756b 4. /build/src/Client/Connection.cpp:1323: DB::Connection::receivePacket() @ 0x00000000167db7d2 5. /build/src/Client/PacketReceiver.cpp:66: DB::PacketReceiver::Task::run(std::function, std::function) @ 0x0000000016819393 6. /build/src/Common/AsyncTaskExecutor.cpp:89: DB::AsyncTaskExecutor::Routine::operator()(std::function) @ 0x0000000013bd1892 7. /build/src/Common/Fiber.h:76: boost::context::detail::fiber_record>::run(void*) @ 0x0000000013bd16fa 8. /build/contrib/boost/boost/context/fiber_fcontext.hpp:97: void boost::context::detail::fiber_entry>>(boost::context::detail::transfer_t) @ 0x0000000013bd1621 Job's origin stack trace: 0. /build/src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000000fc33b84 1. /build/src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000000fcc2ea7 2. /build/src/Common/ThreadPool.cpp:401: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fcc7f1c 3. /build/src/Common/ThreadPool.cpp:494: ThreadPoolImpl>::scheduleOrThrowOnError(std::function, Priority) @ 0x000000000fcc7a0e 4. /build/src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::spawnThreadsImpl() @ 0x00000000169b2c0c 5. /build/src/Processors/Executors/PipelineExecutor.cpp:394: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x00000000169b0ba7 6. /build/src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x00000000169b03f4 7. /build/src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:se190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169bfeab 8. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc3d92 9. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fcca080 10. ? @ 0x00007fbc6213eac3 11. ? @ 0x00007fbc621d0850 Job's origin stack trace: 0. /build/src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000000fc33b84 1. /build/src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000000fcc2ea7 2. /build/src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fcc535c 3. /build/src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000000fcc584d 4. /build/src/Common/ThreadPool.h:279: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x00000000169bf193 5. /build/src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x00000000169bf518 6. /build/src/Server/TCPHandler.cpp:1237: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x00000000168f1525 7. /build/src/Server/TCPHandler.cpp:678: DB::TCPHandler::runImpl() @ 0x00000000168e68e5 8. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 9. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 10. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 11. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 12. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 13. ? @ 0x00007fbc6213eac3 14. ? @ 0x00007fbc621d0850 2025.07.28 11:53:59.908261 [ 3974 ] {} test_13.rmt2 (7f9b740d-015c-470e-8cc6-8ba33be0dc63): auto DB::StorageReplicatedMergeTree::processQueueEntry(ReplicatedMergeTreeQueue::SelectedEntryPtr)::(anonymous class)::operator()(LogEntryPtr &) const: Code: 86. DB::HTTPException: Received error from remote server http://146b4357c08d:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Ftest%2F01165%2Ftest_13%2Frmt%2Freplicas%2F1&part=20250728_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.6.10636.altinitytest (altinity build)) '. (RECEIVED_ERROR_FROM_REMOTE_IO_SERVER), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.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 const&, int&&, String const&, unsigned long&&, String const&) @ 0x000000000feda8d9 4. /build/src/IO/HTTPCommon.cpp:104: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x000000000feda6e2 5. /build/src/IO/HTTPCommon.cpp:93: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x000000000feda537 6. /build/src/IO/ReadWriteBufferFromHTTP.cpp:277: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x000000001184a4c4 7. /build/src/IO/ReadWriteBufferFromHTTP.cpp:285: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x000000001184a615 8. /build/src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x000000001184ae59 9. /build/src/IO/ReadWriteBufferFromHTTP.cpp:472: void std::__function::__policy_invoker::__call_impl[abi:se190107]>(std::__function::__policy_storage const*) @ 0x000000001184cedd 10. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001184858b 11. /build/src/IO/ReadWriteBufferFromHTTP.cpp:465: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x000000001184bf0b 12. /build/src/IO/ReadBuffer.h:60: DB::ReadBuffer::next() @ 0x000000000a148c7b 13. /build/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) @ 0x0000000011849fb2 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]>&)>&, 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&) @ 0x0000000011841980 15. /build/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) @ 0x000000001621208e 16. /build/src/Storages/StorageReplicatedMergeTree.cpp:5228: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl[abi:se190107] const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000015f9a5fe 17. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000015ed8bfd 18. /build/src/Storages/StorageReplicatedMergeTree.cpp:2514: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x0000000015ec9aab 19. /build/src/Storages/StorageReplicatedMergeTree.cpp:2349: DB::StorageReplicatedMergeTree::executeLogEntry(DB::ReplicatedMergeTreeLogEntry&) @ 0x0000000015eba91b 20. /build/src/Storages/StorageReplicatedMergeTree.cpp:3876: bool std::__function::__policy_invoker&)>::__call_impl[abi:se190107])::$_1, bool (std::shared_ptr&)>>(std::__function::__policy_storage const*, std::shared_ptr&) @ 0x0000000015f9837e 21. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000165d6fc3 22. /build/src/Storages/StorageReplicatedMergeTree.cpp:3872: DB::StorageReplicatedMergeTree::processQueueEntry(std::shared_ptr) @ 0x0000000015efc18a 23. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001624c1b2 24. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000162f9c70 25. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x00000000162fa55a 26. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc6653 27. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000000fccc4c3 28. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc3d92 29. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fcca080 30. ? @ 0x00007fbc6213eac3 31. ? @ 0x00007fbc621d0850 (version 25.3.6.10636.altinitytest (altinity build)) 2025.07.28 11:53:59.933444 [ 17255 ] {7bf19523-4328-44b4-9f02-98961226ce0c} executeQuery: Code: 47. DB::Exception: Unknown expression or function identifier `x` in scope x = 1. Maybe you meant: ['a']. (UNKNOWN_IDENTIFIER) (version 25.3.6.10636.altinitytest (altinity build)) (from [::1]:60390) (comment: 01514_parallel_formatting.sql) (query 8, line 10) (in query: select count() from tsv;), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.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&&) @ 0x000000001404b3b9 4. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3771: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000001401b849 5. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3980: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000014018e31 6. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:2925: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000001402fcbd 7. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3838: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000014019a9e 8. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:209: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000001401270e 9. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000014011fce 10. /build/src/Planner/Utils.cpp:458: DB::buildFilterInfo(std::shared_ptr, std::shared_ptr const&, std::shared_ptr&, std::unordered_set, std::equal_to, std::allocator>) @ 0x0000000013fe8bcf 11. /build/src/Planner/PlannerJoinTree.cpp:535: DB::(anonymous namespace)::buildQueryPlanForTableExpression(std::shared_ptr, std::shared_ptr const&, DB::SelectQueryInfo const&, DB::SelectQueryOptions const&, std::shared_ptr&, bool, bool) @ 0x00000000149956d3 12. /build/src/Planner/PlannerJoinTree.cpp:2252: DB::buildJoinTreeQueryPlan(std::shared_ptr const&, DB::SelectQueryInfo const&, DB::SelectQueryOptions&, std::unordered_set, std::equal_to, std::allocator> const&, std::shared_ptr&) @ 0x000000001498e109 13. /build/src/Planner/Planner.cpp:1553: DB::Planner::buildPlanForQueryNode() @ 0x0000000014979dae 14. /build/src/Planner/Planner.cpp:1308: DB::Planner::buildQueryPlanIfNeeded() @ 0x000000001497685c 15. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:255: DB::InterpreterSelectQueryAnalyzer::getQueryPlan() @ 0x000000001497476d 16. /build/src/Interpreters/executeQuery.cpp:1405: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88806 17. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 18. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 19. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 20. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 21. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 22. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 23. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 24. ? @ 0x00007fbc6213eac3 25. ? @ 0x00007fbc621d0850 2025.07.28 11:53:59.986196 [ 17255 ] {} TCPHandler: Code: 47. DB::Exception: Unknown expression or function identifier `x` in scope x = 1. Maybe you meant: ['a']. (UNKNOWN_IDENTIFIER), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.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&&) @ 0x000000001404b3b9 4. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3771: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000001401b849 5. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3980: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000014018e31 6. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:2925: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000001402fcbd 7. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3838: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000014019a9e 8. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:209: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000001401270e 9. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000014011fce 10. /build/src/Planner/Utils.cpp:458: DB::buildFilterInfo(std::shared_ptr, std::shared_ptr const&, std::shared_ptr&, std::unordered_set, std::equal_to, std::allocator>) @ 0x0000000013fe8bcf 11. /build/src/Planner/PlannerJoinTree.cpp:535: DB::(anonymous namespace)::buildQueryPlanForTableExpression(std::shared_ptr, std::shared_ptr const&, DB::SelectQueryInfo const&, DB::SelectQueryOptions const&, std::shared_ptr&, bool, bool) @ 0x00000000149956d3 12. /build/src/Planner/PlannerJoinTree.cpp:2252: DB::buildJoinTreeQueryPlan(std::shared_ptr const&, DB::SelectQueryInfo const&, DB::SelectQueryOptions&, std::unordered_set, std::equal_to, std::allocator> const&, std::shared_ptr&) @ 0x000000001498e109 13. /build/src/Planner/Planner.cpp:1553: DB::Planner::buildPlanForQueryNode() @ 0x0000000014979dae 14. /build/src/Planner/Planner.cpp:1308: DB::Planner::buildQueryPlanIfNeeded() @ 0x000000001497685c 15. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:255: DB::InterpreterSelectQueryAnalyzer::getQueryPlan() @ 0x000000001497476d 16. /build/src/Interpreters/executeQuery.cpp:1405: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88806 17. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 18. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 19. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 20. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 21. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 22. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 23. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 24. ? @ 0x00007fbc6213eac3 25. ? @ 0x00007fbc621d0850 2025.07.28 11:54:00.425214 [ 17203 ] {1722d43f-ce7e-4188-99dc-3a316b131f26} executeQuery: Code: 236. DB::NetException: Client has dropped the connection, cancel the query. (ABORTED) (version 25.3.6.10636.altinitytest (altinity build)) (from [::ffff:127.0.0.1]:41064) (comment: 01822_async_read_from_socket_crash.sh) (query 1, line 1) (in query: SELECT `__table1`.`number` AS `number` FROM numbers(20) AS `__table1` LIMIT _CAST(8, 'UInt64')), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::NetException::NetException(int, T&&) @ 0x0000000016900f80 3. /build/src/Server/TCPHandler.cpp:2426: DB::TCPHandler::receivePacketsExpectCancel(DB::QueryState&) @ 0x00000000168fba18 4. /build/src/Server/TCPHandler.cpp:1242: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x00000000168f1540 5. /build/src/Server/TCPHandler.cpp:678: DB::TCPHandler::runImpl() @ 0x00000000168e68e5 6. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 7. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 8. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 9. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 10. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 11. ? @ 0x00007fbc6213eac3 12. ? @ 0x00007fbc621d0850 2025.07.28 11:54:00.428930 [ 17203 ] {1722d43f-ce7e-4188-99dc-3a316b131f26} 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]:41064). (NETWORK_ERROR), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::NetException::NetException(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&) @ 0x000000000fd50fb5 3. /build/src/IO/WriteBufferFromPocoSocket.cpp:171: DB::WriteBufferFromPocoSocket::nextImpl() @ 0x000000000fd525a7 4. /build/src/IO/WriteBuffer.h:53: DB::WriteBuffer::next() @ 0x000000000a0755be 5. /build/src/Server/TCPHandler.cpp:2620: DB::TCPHandler::sendLogs(DB::QueryState&) @ 0x00000000168f1e17 6. /build/src/Server/TCPHandler.cpp:821: DB::TCPHandler::runImpl() @ 0x00000000168e6c63 7. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 8. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 9. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 10. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 11. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 12. ? @ 0x00007fbc6213eac3 13. ? @ 0x00007fbc621d0850 (version 25.3.6.10636.altinitytest (altinity build)) 2025.07.28 11:54:00.434483 [ 17203 ] {} 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. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::NetException::NetException(int, T&&) @ 0x0000000016900f80 3. /build/src/Server/TCPHandler.cpp:2426: DB::TCPHandler::receivePacketsExpectCancel(DB::QueryState&) @ 0x00000000168fba18 4. /build/src/Server/TCPHandler.cpp:1242: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x00000000168f1540 5. /build/src/Server/TCPHandler.cpp:678: DB::TCPHandler::runImpl() @ 0x00000000168e68e5 6. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 7. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 8. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 9. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 10. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 11. ? @ 0x00007fbc6213eac3 12. ? @ 0x00007fbc621d0850 2025.07.28 11:54:00.437778 [ 5327 ] {3dc69cba-17bc-4c48-91ce-ec74a788b8cf} executeQuery: Code: 100. DB::Exception: Unknown packet 9223372036854775807 from server 127.0.0.2:9000: While executing Remote. (UNKNOWN_PACKET_FROM_SERVER) (version 25.3.6.10636.altinitytest (altinity build)) (from [::1]:60564) (comment: 01822_async_read_from_socket_crash.sh) (query 1, line 1) (in query: select number from remote('127.0.0.{2,3}', numbers(20)) limit 8 settings max_block_size = 2, unknown_packet_in_send_data=4, sleep_in_send_data_ms=100, async_socket_for_remote=1 format Null), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String const&) @ 0x000000000a68756b 4. /build/src/Client/Connection.cpp:1323: DB::Connection::receivePacket() @ 0x00000000167db7d2 5. /build/src/Client/PacketReceiver.cpp:66: DB::PacketReceiver::Task::run(std::function, std::function) @ 0x0000000016819393 6. /build/src/Common/AsyncTaskExecutor.cpp:89: DB::AsyncTaskExecutor::Routine::operator()(std::function) @ 0x0000000013bd1892 7. /build/src/Common/Fiber.h:76: boost::context::detail::fiber_record>::run(void*) @ 0x0000000013bd16fa 8. /build/contrib/boost/boost/context/fiber_fcontext.hpp:97: void boost::context::detail::fiber_entry>>(boost::context::detail::transfer_t) @ 0x0000000013bd1621 2025.07.28 11:54:00.453816 [ 5327 ] {} TCPHandler: Code: 100. DB::Exception: Unknown packet 9223372036854775807 from server 127.0.0.2:9000: While executing Remote. (UNKNOWN_PACKET_FROM_SERVER), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String const&) @ 0x000000000a68756b 4. /build/src/Client/Connection.cpp:1323: DB::Connection::receivePacket() @ 0x00000000167db7d2 5. /build/src/Client/PacketReceiver.cpp:66: DB::PacketReceiver::Task::run(std::function, std::function) @ 0x0000000016819393 6. /build/src/Common/AsyncTaskExecutor.cpp:89: DB::AsyncTaskExecutor::Routine::operator()(std::function) @ 0x0000000013bd1892 7. /build/src/Common/Fiber.h:76: boost::context::detail::fiber_record>::run(void*) @ 0x0000000013bd16fa 8. /build/contrib/boost/boost/context/fiber_fcontext.hpp:97: void boost::context::detail::fiber_entry>>(boost::context::detail::transfer_t) @ 0x0000000013bd1621 Job's origin stack trace: 0. /build/src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000000fc33b84 1. /build/src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000000fcc2ea7 2. /build/src/Common/ThreadPool.cpp:401: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fcc7f1c 3. /build/src/Common/ThreadPool.cpp:494: ThreadPoolImpl>::scheduleOrThrowOnError(std::function, Priority) @ 0x000000000fcc7a0e 4. /build/src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::spawnThreadsImpl() @ 0x00000000169b2c0c 5. /build/src/Processors/Executors/PipelineExecutor.cpp:394: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x00000000169b0ba7 6. /build/src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x00000000169b03f4 7. /build/src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:se190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169bfeab 8. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc3d92 9. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fcca080 10. ? @ 0x00007fbc6213eac3 11. ? @ 0x00007fbc621d0850 Job's origin stack trace: 0. /build/src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000000fc33b84 1. /build/src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000000fcc2ea7 2. /build/src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fcc535c 3. /build/src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000000fcc584d 4. /build/src/Common/ThreadPool.h:279: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x00000000169bf193 5. /build/src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x00000000169bf518 6. /build/src/Server/TCPHandler.cpp:1237: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x00000000168f1525 7. /build/src/Server/TCPHandler.cpp:678: DB::TCPHandler::runImpl() @ 0x00000000168e68e5 8. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 9. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 10. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 11. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 12. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 13. ? @ 0x00007fbc6213eac3 14. ? @ 0x00007fbc621d0850 2025.07.28 11:54:00.477123 [ 17208 ] {4099380f-37a5-4530-bc6c-08e8dd380a20} 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]:60018). (NETWORK_ERROR), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::NetException::NetException(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&) @ 0x000000000fd50fb5 3. /build/src/IO/WriteBufferFromPocoSocket.cpp:160: DB::WriteBufferFromPocoSocket::nextImpl() @ 0x000000000fd523f1 4. /build/src/IO/WriteBuffer.h:53: DB::WriteBuffer::next() @ 0x000000000a0755be 5. /build/src/Server/TCPHandler.cpp:2490: DB::TCPHandler::sendData(DB::QueryState&, DB::Block const&) @ 0x00000000168fa306 6. /build/src/Server/TCPHandler.cpp:1266: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x00000000168f162c 7. /build/src/Server/TCPHandler.cpp:678: DB::TCPHandler::runImpl() @ 0x00000000168e68e5 8. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 9. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 10. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 11. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 12. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 13. ? @ 0x00007fbc6213eac3 14. ? @ 0x00007fbc621d0850 (version 25.3.6.10636.altinitytest (altinity build)) 2025.07.28 11:54:00.498818 [ 17306 ] {041028fb-eafa-43bd-9739-f9791ff06148} executeQuery: Code: 153. DB::Exception: Division by zero: while executing 'FUNCTION modulo(1_UInt8 :: 1, modulo(plus(__table1.number, 500_UInt16), 1000_UInt16) :: 2) -> modulo(1_UInt8, modulo(plus(__table1.number, 500_UInt16), 1000_UInt16)) UInt16 : 3'. (ILLEGAL_DIVISION) (version 25.3.6.10636.altinitytest (altinity build)) (from [::1]:60426) (comment: 00093_union_race_conditions_4.sh) (query 1, line 1) (in query: SELECT 1 % ((number + 500) % 1000) FROM numbers_mt(1000);), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000000a074fcb 4. /build/src/Functions/DivisionUtils.h:26: void DB::impl_::BinaryOperation, unsigned short>::process<(DB::impl_::OpCase)1>(char8_t const*, unsigned short const*, unsigned short*, unsigned long, DB::PODArray, 63ul, 64ul> const*) @ 0x000000000d184621 5. /build/src/Functions/FunctionBinaryArithmetic.h:2338: COW::immutable_ptr DB::FunctionBinaryArithmetic::executeNumeric, DB::DataTypeNumber>(std::vector> const&, DB::DataTypeNumber const&, DB::DataTypeNumber const&, DB::PODArray, 63ul, 64ul> const*) const @ 0x000000000d3a6416 6. /build/src/Functions/FunctionBinaryArithmetic.h:2508: 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&&) @ 0x000000000d3a4a68 7. /build/src/Functions/FunctionBinaryArithmetic.h:846: 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&&) @ 0x000000000d3a3ec7 8. /build/src/Functions/FunctionBinaryArithmetic.h:844: DB::FunctionBinaryArithmetic::executeImpl2(std::vector> const&, std::shared_ptr const&, unsigned long, DB::PODArray, 63ul, 64ul> const*) const @ 0x000000000d3a03c5 9. /build/src/Functions/FunctionBinaryArithmetic.h:2410: DB::FunctionBinaryArithmetic::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000d39e94c 10. /build/src/Functions/FunctionBinaryArithmetic.h:2645: DB::FunctionBinaryArithmeticWithConstants::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000d39dbd4 11. /build/src/Functions/IFunctionAdaptors.cpp:10: DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000012d995fa 12. /build/src/Functions/IFunction.cpp:353: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d93b52 13. /build/src/Functions/IFunction.cpp:420: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d95059 14. /build/src/Functions/IFunction.cpp:498: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d95c72 15. /build/src/Interpreters/ExpressionActions.cpp:636: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x00000000145176f3 16. /build/src/Processors/Transforms/ExpressionTransform.cpp:25: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x0000000016c0b34c 17. /build/src/Processors/ISimpleTransform.h:33: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000011a9a453 18. /build/src/Processors/ISimpleTransform.cpp:89: DB::ISimpleTransform::work() @ 0x000000001699fca0 19. /build/src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x00000000169bd00f 20. /build/src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x00000000169b2105 21. /build/src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeSingleThread(unsigned long) @ 0x00000000169b23be 22. /build/src/Processors/Executors/PipelineExecutor.cpp:454: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x00000000169b0be7 23. /build/src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x00000000169b03f4 24. /build/src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:se190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169bfeab 25. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc3d92 26. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fcca080 27. ? @ 0x00007fbc6213eac3 28. ? @ 0x00007fbc621d0850 2025.07.28 11:54:00.549538 [ 17208 ] {4099380f-37a5-4530-bc6c-08e8dd380a20} executeQuery: Code: 210. DB::NetException: Connection reset by peer, while writing to socket ([::ffff:127.0.0.3]:9000 -> [::ffff:127.0.0.1]:60018). (NETWORK_ERROR) (version 25.3.6.10636.altinitytest (altinity build)) (from [::ffff:127.0.0.1]:60018) (comment: 01822_async_read_from_socket_crash.sh) (query 1, line 1) (in query: SELECT `__table1`.`number` AS `number` FROM numbers(20) AS `__table1` LIMIT _CAST(8, 'UInt64')), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::NetException::NetException(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&) @ 0x000000000fd50fb5 3. /build/src/IO/WriteBufferFromPocoSocket.cpp:160: DB::WriteBufferFromPocoSocket::nextImpl() @ 0x000000000fd523f1 4. /build/src/IO/WriteBuffer.h:53: DB::WriteBuffer::next() @ 0x000000000a0755be 5. /build/src/Server/TCPHandler.cpp:2490: DB::TCPHandler::sendData(DB::QueryState&, DB::Block const&) @ 0x00000000168fa306 6. /build/src/Server/TCPHandler.cpp:1266: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x00000000168f162c 7. /build/src/Server/TCPHandler.cpp:678: DB::TCPHandler::runImpl() @ 0x00000000168e68e5 8. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 9. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 10. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 11. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 12. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 13. ? @ 0x00007fbc6213eac3 14. ? @ 0x00007fbc621d0850 2025.07.28 11:54:00.566119 [ 17208 ] {} TCPHandler: Code: 210. DB::NetException: Connection reset by peer, while writing to socket ([::ffff:127.0.0.3]:9000 -> [::ffff:127.0.0.1]:60018). (NETWORK_ERROR), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::NetException::NetException(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&) @ 0x000000000fd50fb5 3. /build/src/IO/WriteBufferFromPocoSocket.cpp:160: DB::WriteBufferFromPocoSocket::nextImpl() @ 0x000000000fd523f1 4. /build/src/IO/WriteBuffer.h:53: DB::WriteBuffer::next() @ 0x000000000a0755be 5. /build/src/Server/TCPHandler.cpp:2490: DB::TCPHandler::sendData(DB::QueryState&, DB::Block const&) @ 0x00000000168fa306 6. /build/src/Server/TCPHandler.cpp:1266: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x00000000168f162c 7. /build/src/Server/TCPHandler.cpp:678: DB::TCPHandler::runImpl() @ 0x00000000168e68e5 8. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 9. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 10. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 11. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 12. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 13. ? @ 0x00007fbc6213eac3 14. ? @ 0x00007fbc621d0850 2025.07.28 11:54:00.569618 [ 17306 ] {} TCPHandler: Code: 153. DB::Exception: Division by zero: while executing 'FUNCTION modulo(1_UInt8 :: 1, modulo(plus(__table1.number, 500_UInt16), 1000_UInt16) :: 2) -> modulo(1_UInt8, modulo(plus(__table1.number, 500_UInt16), 1000_UInt16)) UInt16 : 3'. (ILLEGAL_DIVISION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000000a074fcb 4. /build/src/Functions/DivisionUtils.h:26: void DB::impl_::BinaryOperation, unsigned short>::process<(DB::impl_::OpCase)1>(char8_t const*, unsigned short const*, unsigned short*, unsigned long, DB::PODArray, 63ul, 64ul> const*) @ 0x000000000d184621 5. /build/src/Functions/FunctionBinaryArithmetic.h:2338: COW::immutable_ptr DB::FunctionBinaryArithmetic::executeNumeric, DB::DataTypeNumber>(std::vector> const&, DB::DataTypeNumber const&, DB::DataTypeNumber const&, DB::PODArray, 63ul, 64ul> const*) const @ 0x000000000d3a6416 6. /build/src/Functions/FunctionBinaryArithmetic.h:2508: 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&&) @ 0x000000000d3a4a68 7. /build/src/Functions/FunctionBinaryArithmetic.h:846: 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&&) @ 0x000000000d3a3ec7 8. /build/src/Functions/FunctionBinaryArithmetic.h:844: DB::FunctionBinaryArithmetic::executeImpl2(std::vector> const&, std::shared_ptr const&, unsigned long, DB::PODArray, 63ul, 64ul> const*) const @ 0x000000000d3a03c5 9. /build/src/Functions/FunctionBinaryArithmetic.h:2410: DB::FunctionBinaryArithmetic::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000d39e94c 10. /build/src/Functions/FunctionBinaryArithmetic.h:2645: DB::FunctionBinaryArithmeticWithConstants::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000d39dbd4 11. /build/src/Functions/IFunctionAdaptors.cpp:10: DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000012d995fa 12. /build/src/Functions/IFunction.cpp:353: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d93b52 13. /build/src/Functions/IFunction.cpp:420: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d95059 14. /build/src/Functions/IFunction.cpp:498: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d95c72 15. /build/src/Interpreters/ExpressionActions.cpp:636: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x00000000145176f3 16. /build/src/Processors/Transforms/ExpressionTransform.cpp:25: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x0000000016c0b34c 17. /build/src/Processors/ISimpleTransform.h:33: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000011a9a453 18. /build/src/Processors/ISimpleTransform.cpp:89: DB::ISimpleTransform::work() @ 0x000000001699fca0 19. /build/src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x00000000169bd00f 20. /build/src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x00000000169b2105 21. /build/src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeSingleThread(unsigned long) @ 0x00000000169b23be 22. /build/src/Processors/Executors/PipelineExecutor.cpp:454: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x00000000169b0be7 23. /build/src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x00000000169b03f4 24. /build/src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:se190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169bfeab 25. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc3d92 26. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fcca080 27. ? @ 0x00007fbc6213eac3 28. ? @ 0x00007fbc621d0850 Job's origin stack trace: 0. /build/src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000000fc33b84 1. /build/src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000000fcc2ea7 2. /build/src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fcc535c 3. /build/src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000000fcc584d 4. /build/src/Common/ThreadPool.h:279: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x00000000169bf193 5. /build/src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x00000000169bf518 6. /build/src/Server/TCPHandler.cpp:1237: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x00000000168f1525 7. /build/src/Server/TCPHandler.cpp:678: DB::TCPHandler::runImpl() @ 0x00000000168e68e5 8. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 9. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 10. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 11. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 12. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 13. ? @ 0x00007fbc6213eac3 14. ? @ 0x00007fbc621d0850 2025.07.28 11:54:00.886928 [ 3977 ] {} test_13.rmt2 (7f9b740d-015c-470e-8cc6-8ba33be0dc63): auto DB::StorageReplicatedMergeTree::processQueueEntry(ReplicatedMergeTreeQueue::SelectedEntryPtr)::(anonymous class)::operator()(LogEntryPtr &) const: Code: 86. DB::HTTPException: Received error from remote server http://146b4357c08d:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Ftest%2F01165%2Ftest_13%2Frmt%2Freplicas%2F1&part=20250728_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.6.10636.altinitytest (altinity build)) '. (RECEIVED_ERROR_FROM_REMOTE_IO_SERVER), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.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 const&, int&&, String const&, unsigned long&&, String const&) @ 0x000000000feda8d9 4. /build/src/IO/HTTPCommon.cpp:104: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x000000000feda6e2 5. /build/src/IO/HTTPCommon.cpp:93: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x000000000feda537 6. /build/src/IO/ReadWriteBufferFromHTTP.cpp:277: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x000000001184a4c4 7. /build/src/IO/ReadWriteBufferFromHTTP.cpp:285: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x000000001184a615 8. /build/src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x000000001184ae59 9. /build/src/IO/ReadWriteBufferFromHTTP.cpp:472: void std::__function::__policy_invoker::__call_impl[abi:se190107]>(std::__function::__policy_storage const*) @ 0x000000001184cedd 10. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001184858b 11. /build/src/IO/ReadWriteBufferFromHTTP.cpp:465: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x000000001184bf0b 12. /build/src/IO/ReadBuffer.h:60: DB::ReadBuffer::next() @ 0x000000000a148c7b 13. /build/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) @ 0x0000000011849fb2 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]>&)>&, 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&) @ 0x0000000011841980 15. /build/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) @ 0x000000001621208e 16. /build/src/Storages/StorageReplicatedMergeTree.cpp:5228: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl[abi:se190107] const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000015f9a5fe 17. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000015ed8bfd 18. /build/src/Storages/StorageReplicatedMergeTree.cpp:2514: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x0000000015ec9aab 19. /build/src/Storages/StorageReplicatedMergeTree.cpp:2349: DB::StorageReplicatedMergeTree::executeLogEntry(DB::ReplicatedMergeTreeLogEntry&) @ 0x0000000015eba91b 20. /build/src/Storages/StorageReplicatedMergeTree.cpp:3876: bool std::__function::__policy_invoker&)>::__call_impl[abi:se190107])::$_1, bool (std::shared_ptr&)>>(std::__function::__policy_storage const*, std::shared_ptr&) @ 0x0000000015f9837e 21. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000165d6fc3 22. /build/src/Storages/StorageReplicatedMergeTree.cpp:3872: DB::StorageReplicatedMergeTree::processQueueEntry(std::shared_ptr) @ 0x0000000015efc18a 23. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001624c1b2 24. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000162f9c70 25. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x00000000162fa55a 26. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc6653 27. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000000fccc4c3 28. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc3d92 29. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fcca080 30. ? @ 0x00007fbc6213eac3 31. ? @ 0x00007fbc621d0850 (version 25.3.6.10636.altinitytest (altinity build)) 2025.07.28 11:54:01.040374 [ 3971 ] {} test_13.rmt2 (7f9b740d-015c-470e-8cc6-8ba33be0dc63): auto DB::StorageReplicatedMergeTree::processQueueEntry(ReplicatedMergeTreeQueue::SelectedEntryPtr)::(anonymous class)::operator()(LogEntryPtr &) const: Code: 86. DB::HTTPException: Received error from remote server http://146b4357c08d:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Ftest%2F01165%2Ftest_13%2Frmt%2Freplicas%2F1&part=20250728_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.6.10636.altinitytest (altinity build)) '. (RECEIVED_ERROR_FROM_REMOTE_IO_SERVER), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.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 const&, int&&, String const&, unsigned long&&, String const&) @ 0x000000000feda8d9 4. /build/src/IO/HTTPCommon.cpp:104: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x000000000feda6e2 5. /build/src/IO/HTTPCommon.cpp:93: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x000000000feda537 6. /build/src/IO/ReadWriteBufferFromHTTP.cpp:277: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x000000001184a4c4 7. /build/src/IO/ReadWriteBufferFromHTTP.cpp:285: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x000000001184a615 8. /build/src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x000000001184ae59 9. /build/src/IO/ReadWriteBufferFromHTTP.cpp:472: void std::__function::__policy_invoker::__call_impl[abi:se190107]>(std::__function::__policy_storage const*) @ 0x000000001184cedd 10. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001184858b 11. /build/src/IO/ReadWriteBufferFromHTTP.cpp:465: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x000000001184bf0b 12. /build/src/IO/ReadBuffer.h:60: DB::ReadBuffer::next() @ 0x000000000a148c7b 13. /build/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) @ 0x0000000011849fb2 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]>&)>&, 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&) @ 0x0000000011841980 15. /build/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) @ 0x000000001621208e 16. /build/src/Storages/StorageReplicatedMergeTree.cpp:5228: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl[abi:se190107] const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000015f9a5fe 17. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000015ed8bfd 18. /build/src/Storages/StorageReplicatedMergeTree.cpp:2514: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x0000000015ec9aab 19. /build/src/Storages/StorageReplicatedMergeTree.cpp:2349: DB::StorageReplicatedMergeTree::executeLogEntry(DB::ReplicatedMergeTreeLogEntry&) @ 0x0000000015eba91b 20. /build/src/Storages/StorageReplicatedMergeTree.cpp:3876: bool std::__function::__policy_invoker&)>::__call_impl[abi:se190107])::$_1, bool (std::shared_ptr&)>>(std::__function::__policy_storage const*, std::shared_ptr&) @ 0x0000000015f9837e 21. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000165d6fc3 22. /build/src/Storages/StorageReplicatedMergeTree.cpp:3872: DB::StorageReplicatedMergeTree::processQueueEntry(std::shared_ptr) @ 0x0000000015efc18a 23. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001624c1b2 24. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000162f9c70 25. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x00000000162fa55a 26. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc6653 27. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000000fccc4c3 28. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc3d92 29. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fcca080 30. ? @ 0x00007fbc6213eac3 31. ? @ 0x00007fbc621d0850 (version 25.3.6.10636.altinitytest (altinity build)) 2025.07.28 11:54:01.506072 [ 3972 ] {} test_13.rmt2 (7f9b740d-015c-470e-8cc6-8ba33be0dc63): auto DB::StorageReplicatedMergeTree::processQueueEntry(ReplicatedMergeTreeQueue::SelectedEntryPtr)::(anonymous class)::operator()(LogEntryPtr &) const: Code: 86. DB::HTTPException: Received error from remote server http://146b4357c08d:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Ftest%2F01165%2Ftest_13%2Frmt%2Freplicas%2F1&part=20250728_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.6.10636.altinitytest (altinity build)) '. (RECEIVED_ERROR_FROM_REMOTE_IO_SERVER), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.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 const&, int&&, String const&, unsigned long&&, String const&) @ 0x000000000feda8d9 4. /build/src/IO/HTTPCommon.cpp:104: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x000000000feda6e2 5. /build/src/IO/HTTPCommon.cpp:93: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x000000000feda537 6. /build/src/IO/ReadWriteBufferFromHTTP.cpp:277: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x000000001184a4c4 7. /build/src/IO/ReadWriteBufferFromHTTP.cpp:285: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x000000001184a615 8. /build/src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x000000001184ae59 9. /build/src/IO/ReadWriteBufferFromHTTP.cpp:472: void std::__function::__policy_invoker::__call_impl[abi:se190107]>(std::__function::__policy_storage const*) @ 0x000000001184cedd 10. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001184858b 11. /build/src/IO/ReadWriteBufferFromHTTP.cpp:465: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x000000001184bf0b 12. /build/src/IO/ReadBuffer.h:60: DB::ReadBuffer::next() @ 0x000000000a148c7b 13. /build/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) @ 0x0000000011849fb2 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]>&)>&, 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&) @ 0x0000000011841980 15. /build/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) @ 0x000000001621208e 16. /build/src/Storages/StorageReplicatedMergeTree.cpp:5228: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl[abi:se190107] const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000015f9a5fe 17. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000015ed8bfd 18. /build/src/Storages/StorageReplicatedMergeTree.cpp:2514: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x0000000015ec9aab 19. /build/src/Storages/StorageReplicatedMergeTree.cpp:2349: DB::StorageReplicatedMergeTree::executeLogEntry(DB::ReplicatedMergeTreeLogEntry&) @ 0x0000000015eba91b 20. /build/src/Storages/StorageReplicatedMergeTree.cpp:3876: bool std::__function::__policy_invoker&)>::__call_impl[abi:se190107])::$_1, bool (std::shared_ptr&)>>(std::__function::__policy_storage const*, std::shared_ptr&) @ 0x0000000015f9837e 21. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000165d6fc3 22. /build/src/Storages/StorageReplicatedMergeTree.cpp:3872: DB::StorageReplicatedMergeTree::processQueueEntry(std::shared_ptr) @ 0x0000000015efc18a 23. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001624c1b2 24. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000162f9c70 25. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x00000000162fa55a 26. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc6653 27. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000000fccc4c3 28. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc3d92 29. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fcca080 30. ? @ 0x00007fbc6213eac3 31. ? @ 0x00007fbc621d0850 (version 25.3.6.10636.altinitytest (altinity build)) 2025.07.28 11:54:01.608928 [ 4963 ] {5236ea28-ed8a-44e2-98a2-5242f9ec981b} executeQuery: Code: 100. DB::Exception: Unknown packet 9223372036854775807 from server 127.0.0.2:9000: While executing Remote. (UNKNOWN_PACKET_FROM_SERVER) (version 25.3.6.10636.altinitytest (altinity build)) (from [::1]:60602) (comment: 01822_async_read_from_socket_crash.sh) (query 1, line 1) (in query: select number from remote('127.0.0.{2,3}', numbers(20)) limit 8 settings max_block_size = 2, unknown_packet_in_send_data=4, sleep_in_send_data_ms=100, async_socket_for_remote=1 format Null), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String const&) @ 0x000000000a68756b 4. /build/src/Client/Connection.cpp:1323: DB::Connection::receivePacket() @ 0x00000000167db7d2 5. /build/src/Client/PacketReceiver.cpp:66: DB::PacketReceiver::Task::run(std::function, std::function) @ 0x0000000016819393 6. /build/src/Common/AsyncTaskExecutor.cpp:89: DB::AsyncTaskExecutor::Routine::operator()(std::function) @ 0x0000000013bd1892 7. /build/src/Common/Fiber.h:76: boost::context::detail::fiber_record>::run(void*) @ 0x0000000013bd16fa 8. /build/contrib/boost/boost/context/fiber_fcontext.hpp:97: void boost::context::detail::fiber_entry>>(boost::context::detail::transfer_t) @ 0x0000000013bd1621 2025.07.28 11:54:01.643885 [ 17208 ] {4b2ddbe8-6230-4a83-874d-1ff8fd3106a7} 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]:46638). (NETWORK_ERROR), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::NetException::NetException(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&) @ 0x000000000fd50fb5 3. /build/src/IO/WriteBufferFromPocoSocket.cpp:171: DB::WriteBufferFromPocoSocket::nextImpl() @ 0x000000000fd525a7 4. /build/src/IO/WriteBuffer.h:53: DB::WriteBuffer::next() @ 0x000000000a0755be 5. /build/src/Server/TCPHandler.cpp:824: DB::TCPHandler::runImpl() @ 0x00000000168e6c86 6. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 7. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 8. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 9. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 10. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 11. ? @ 0x00007fbc6213eac3 12. ? @ 0x00007fbc621d0850 (version 25.3.6.10636.altinitytest (altinity build)) 2025.07.28 11:54:01.655033 [ 4963 ] {} TCPHandler: Code: 100. DB::Exception: Unknown packet 9223372036854775807 from server 127.0.0.2:9000: While executing Remote. (UNKNOWN_PACKET_FROM_SERVER), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String const&) @ 0x000000000a68756b 4. /build/src/Client/Connection.cpp:1323: DB::Connection::receivePacket() @ 0x00000000167db7d2 5. /build/src/Client/PacketReceiver.cpp:66: DB::PacketReceiver::Task::run(std::function, std::function) @ 0x0000000016819393 6. /build/src/Common/AsyncTaskExecutor.cpp:89: DB::AsyncTaskExecutor::Routine::operator()(std::function) @ 0x0000000013bd1892 7. /build/src/Common/Fiber.h:76: boost::context::detail::fiber_record>::run(void*) @ 0x0000000013bd16fa 8. /build/contrib/boost/boost/context/fiber_fcontext.hpp:97: void boost::context::detail::fiber_entry>>(boost::context::detail::transfer_t) @ 0x0000000013bd1621 Job's origin stack trace: 0. /build/src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000000fc33b84 1. /build/src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000000fcc2ea7 2. /build/src/Common/ThreadPool.cpp:401: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fcc7f1c 3. /build/src/Common/ThreadPool.cpp:494: ThreadPoolImpl>::scheduleOrThrowOnError(std::function, Priority) @ 0x000000000fcc7a0e 4. /build/src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::spawnThreadsImpl() @ 0x00000000169b2c0c 5. /build/src/Processors/Executors/PipelineExecutor.cpp:394: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x00000000169b0ba7 6. /build/src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x00000000169b03f4 7. /build/src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:se190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169bfeab 8. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc3d92 9. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fcca080 10. ? @ 0x00007fbc6213eac3 11. ? @ 0x00007fbc621d0850 Job's origin stack trace: 0. /build/src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000000fc33b84 1. /build/src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000000fcc2ea7 2. /build/src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fcc535c 3. /build/src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000000fcc584d 4. /build/src/Common/ThreadPool.h:279: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x00000000169bf193 5. /build/src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x00000000169bf518 6. /build/src/Server/TCPHandler.cpp:1237: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x00000000168f1525 7. /build/src/Server/TCPHandler.cpp:678: DB::TCPHandler::runImpl() @ 0x00000000168e68e5 8. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 9. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 10. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 11. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 12. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 13. ? @ 0x00007fbc6213eac3 14. ? @ 0x00007fbc621d0850 2025.07.28 11:54:01.666814 [ 5951 ] {c80e8e02-5879-4d2e-99ce-a158f7463d6e} executeQuery: Code: 236. DB::NetException: Client has dropped the connection, cancel the query. (ABORTED) (version 25.3.6.10636.altinitytest (altinity build)) (from [::ffff:127.0.0.1]:41066) (comment: 01822_async_read_from_socket_crash.sh) (query 1, line 1) (in query: SELECT `__table1`.`number` AS `number` FROM numbers(20) AS `__table1` LIMIT _CAST(8, 'UInt64')), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::NetException::NetException(int, T&&) @ 0x0000000016900f80 3. /build/src/Server/TCPHandler.cpp:2426: DB::TCPHandler::receivePacketsExpectCancel(DB::QueryState&) @ 0x00000000168fba18 4. /build/src/Server/TCPHandler.cpp:1242: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x00000000168f1540 5. /build/src/Server/TCPHandler.cpp:678: DB::TCPHandler::runImpl() @ 0x00000000168e68e5 6. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 7. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 8. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 9. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 10. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 11. ? @ 0x00007fbc6213eac3 12. ? @ 0x00007fbc621d0850 2025.07.28 11:54:01.679008 [ 5951 ] {c80e8e02-5879-4d2e-99ce-a158f7463d6e} 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]:41066). (NETWORK_ERROR), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::NetException::NetException(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&) @ 0x000000000fd50fb5 3. /build/src/IO/WriteBufferFromPocoSocket.cpp:171: DB::WriteBufferFromPocoSocket::nextImpl() @ 0x000000000fd525a7 4. /build/src/IO/WriteBuffer.h:53: DB::WriteBuffer::next() @ 0x000000000a0755be 5. /build/src/Server/TCPHandler.cpp:2620: DB::TCPHandler::sendLogs(DB::QueryState&) @ 0x00000000168f1e17 6. /build/src/Server/TCPHandler.cpp:821: DB::TCPHandler::runImpl() @ 0x00000000168e6c63 7. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 8. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 9. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 10. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 11. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 12. ? @ 0x00007fbc6213eac3 13. ? @ 0x00007fbc621d0850 (version 25.3.6.10636.altinitytest (altinity build)) 2025.07.28 11:54:01.682514 [ 5951 ] {} 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. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::NetException::NetException(int, T&&) @ 0x0000000016900f80 3. /build/src/Server/TCPHandler.cpp:2426: DB::TCPHandler::receivePacketsExpectCancel(DB::QueryState&) @ 0x00000000168fba18 4. /build/src/Server/TCPHandler.cpp:1242: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x00000000168f1540 5. /build/src/Server/TCPHandler.cpp:678: DB::TCPHandler::runImpl() @ 0x00000000168e68e5 6. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 7. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 8. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 9. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 10. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 11. ? @ 0x00007fbc6213eac3 12. ? @ 0x00007fbc621d0850 2025.07.28 11:54:02.360894 [ 3970 ] {} test_13.rmt2 (7f9b740d-015c-470e-8cc6-8ba33be0dc63): auto DB::StorageReplicatedMergeTree::processQueueEntry(ReplicatedMergeTreeQueue::SelectedEntryPtr)::(anonymous class)::operator()(LogEntryPtr &) const: Code: 86. DB::HTTPException: Received error from remote server http://146b4357c08d:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Ftest%2F01165%2Ftest_13%2Frmt%2Freplicas%2F1&part=20250728_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.6.10636.altinitytest (altinity build)) '. (RECEIVED_ERROR_FROM_REMOTE_IO_SERVER), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.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 const&, int&&, String const&, unsigned long&&, String const&) @ 0x000000000feda8d9 4. /build/src/IO/HTTPCommon.cpp:104: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x000000000feda6e2 5. /build/src/IO/HTTPCommon.cpp:93: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x000000000feda537 6. /build/src/IO/ReadWriteBufferFromHTTP.cpp:277: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x000000001184a4c4 7. /build/src/IO/ReadWriteBufferFromHTTP.cpp:285: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x000000001184a615 8. /build/src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x000000001184ae59 9. /build/src/IO/ReadWriteBufferFromHTTP.cpp:472: void std::__function::__policy_invoker::__call_impl[abi:se190107]>(std::__function::__policy_storage const*) @ 0x000000001184cedd 10. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001184858b 11. /build/src/IO/ReadWriteBufferFromHTTP.cpp:465: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x000000001184bf0b 12. /build/src/IO/ReadBuffer.h:60: DB::ReadBuffer::next() @ 0x000000000a148c7b 13. /build/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) @ 0x0000000011849fb2 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]>&)>&, 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&) @ 0x0000000011841980 15. /build/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) @ 0x000000001621208e 16. /build/src/Storages/StorageReplicatedMergeTree.cpp:5228: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl[abi:se190107] const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000015f9a5fe 17. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000015ed8bfd 18. /build/src/Storages/StorageReplicatedMergeTree.cpp:2514: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x0000000015ec9aab 19. /build/src/Storages/StorageReplicatedMergeTree.cpp:2349: DB::StorageReplicatedMergeTree::executeLogEntry(DB::ReplicatedMergeTreeLogEntry&) @ 0x0000000015eba91b 20. /build/src/Storages/StorageReplicatedMergeTree.cpp:3876: bool std::__function::__policy_invoker&)>::__call_impl[abi:se190107])::$_1, bool (std::shared_ptr&)>>(std::__function::__policy_storage const*, std::shared_ptr&) @ 0x0000000015f9837e 21. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000165d6fc3 22. /build/src/Storages/StorageReplicatedMergeTree.cpp:3872: DB::StorageReplicatedMergeTree::processQueueEntry(std::shared_ptr) @ 0x0000000015efc18a 23. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001624c1b2 24. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000162f9c70 25. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x00000000162fa55a 26. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc6653 27. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000000fccc4c3 28. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc3d92 29. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fcca080 30. ? @ 0x00007fbc6213eac3 31. ? @ 0x00007fbc621d0850 (version 25.3.6.10636.altinitytest (altinity build)) 2025.07.28 11:54:02.693938 [ 3971 ] {} test_13.rmt2 (7f9b740d-015c-470e-8cc6-8ba33be0dc63): auto DB::StorageReplicatedMergeTree::processQueueEntry(ReplicatedMergeTreeQueue::SelectedEntryPtr)::(anonymous class)::operator()(LogEntryPtr &) const: Code: 86. DB::HTTPException: Received error from remote server http://146b4357c08d:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Ftest%2F01165%2Ftest_13%2Frmt%2Freplicas%2F1&part=20250728_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.6.10636.altinitytest (altinity build)) '. (RECEIVED_ERROR_FROM_REMOTE_IO_SERVER), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.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 const&, int&&, String const&, unsigned long&&, String const&) @ 0x000000000feda8d9 4. /build/src/IO/HTTPCommon.cpp:104: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x000000000feda6e2 5. /build/src/IO/HTTPCommon.cpp:93: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x000000000feda537 6. /build/src/IO/ReadWriteBufferFromHTTP.cpp:277: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x000000001184a4c4 7. /build/src/IO/ReadWriteBufferFromHTTP.cpp:285: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x000000001184a615 8. /build/src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x000000001184ae59 9. /build/src/IO/ReadWriteBufferFromHTTP.cpp:472: void std::__function::__policy_invoker::__call_impl[abi:se190107]>(std::__function::__policy_storage const*) @ 0x000000001184cedd 10. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001184858b 11. /build/src/IO/ReadWriteBufferFromHTTP.cpp:465: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x000000001184bf0b 12. /build/src/IO/ReadBuffer.h:60: DB::ReadBuffer::next() @ 0x000000000a148c7b 13. /build/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) @ 0x0000000011849fb2 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]>&)>&, 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&) @ 0x0000000011841980 15. /build/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) @ 0x000000001621208e 16. /build/src/Storages/StorageReplicatedMergeTree.cpp:5228: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl[abi:se190107] const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000015f9a5fe 17. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000015ed8bfd 18. /build/src/Storages/StorageReplicatedMergeTree.cpp:2514: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x0000000015ec9aab 19. /build/src/Storages/StorageReplicatedMergeTree.cpp:2349: DB::StorageReplicatedMergeTree::executeLogEntry(DB::ReplicatedMergeTreeLogEntry&) @ 0x0000000015eba91b 20. /build/src/Storages/StorageReplicatedMergeTree.cpp:3876: bool std::__function::__policy_invoker&)>::__call_impl[abi:se190107])::$_1, bool (std::shared_ptr&)>>(std::__function::__policy_storage const*, std::shared_ptr&) @ 0x0000000015f9837e 21. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000165d6fc3 22. /build/src/Storages/StorageReplicatedMergeTree.cpp:3872: DB::StorageReplicatedMergeTree::processQueueEntry(std::shared_ptr) @ 0x0000000015efc18a 23. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001624c1b2 24. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000162f9c70 25. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x00000000162fa55a 26. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc6653 27. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000000fccc4c3 28. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc3d92 29. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fcca080 30. ? @ 0x00007fbc6213eac3 31. ? @ 0x00007fbc621d0850 (version 25.3.6.10636.altinitytest (altinity build)) 2025.07.28 11:54:02.772385 [ 17208 ] {d70bcd61-8333-4c44-b376-958d60018302} executeQuery: Code: 100. DB::Exception: Unknown packet 9223372036854775807 from server 127.0.0.2:9000: While executing Remote. (UNKNOWN_PACKET_FROM_SERVER) (version 25.3.6.10636.altinitytest (altinity build)) (from [::1]:35752) (comment: 01822_async_read_from_socket_crash.sh) (query 1, line 1) (in query: select number from remote('127.0.0.{2,3}', numbers(20)) limit 8 settings max_block_size = 2, unknown_packet_in_send_data=4, sleep_in_send_data_ms=100, async_socket_for_remote=1 format Null), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String const&) @ 0x000000000a68756b 4. /build/src/Client/Connection.cpp:1323: DB::Connection::receivePacket() @ 0x00000000167db7d2 5. /build/src/Client/PacketReceiver.cpp:66: DB::PacketReceiver::Task::run(std::function, std::function) @ 0x0000000016819393 6. /build/src/Common/AsyncTaskExecutor.cpp:89: DB::AsyncTaskExecutor::Routine::operator()(std::function) @ 0x0000000013bd1892 7. /build/src/Common/Fiber.h:76: boost::context::detail::fiber_record>::run(void*) @ 0x0000000013bd16fa 8. /build/contrib/boost/boost/context/fiber_fcontext.hpp:97: void boost::context::detail::fiber_entry>>(boost::context::detail::transfer_t) @ 0x0000000013bd1621 2025.07.28 11:54:02.784867 [ 5951 ] {b82c118a-b426-4140-a879-07c607eb4b79} executeQuery: Code: 236. DB::NetException: Client has dropped the connection, cancel the query. (ABORTED) (version 25.3.6.10636.altinitytest (altinity build)) (from [::ffff:127.0.0.1]:58632) (comment: 01822_async_read_from_socket_crash.sh) (query 1, line 1) (in query: SELECT `__table1`.`number` AS `number` FROM numbers(20) AS `__table1` LIMIT _CAST(8, 'UInt64')), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::NetException::NetException(int, T&&) @ 0x0000000016900f80 3. /build/src/Server/TCPHandler.cpp:2426: DB::TCPHandler::receivePacketsExpectCancel(DB::QueryState&) @ 0x00000000168fba18 4. /build/src/Server/TCPHandler.cpp:1242: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x00000000168f1540 5. /build/src/Server/TCPHandler.cpp:678: DB::TCPHandler::runImpl() @ 0x00000000168e68e5 6. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 7. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 8. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 9. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 10. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 11. ? @ 0x00007fbc6213eac3 12. ? @ 0x00007fbc621d0850 2025.07.28 11:54:02.787032 [ 5951 ] {b82c118a-b426-4140-a879-07c607eb4b79} 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]:58632). (NETWORK_ERROR), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::NetException::NetException(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&) @ 0x000000000fd50fb5 3. /build/src/IO/WriteBufferFromPocoSocket.cpp:171: DB::WriteBufferFromPocoSocket::nextImpl() @ 0x000000000fd525a7 4. /build/src/IO/WriteBuffer.h:53: DB::WriteBuffer::next() @ 0x000000000a0755be 5. /build/src/Server/TCPHandler.cpp:2620: DB::TCPHandler::sendLogs(DB::QueryState&) @ 0x00000000168f1e17 6. /build/src/Server/TCPHandler.cpp:821: DB::TCPHandler::runImpl() @ 0x00000000168e6c63 7. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 8. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 9. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 10. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 11. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 12. ? @ 0x00007fbc6213eac3 13. ? @ 0x00007fbc621d0850 (version 25.3.6.10636.altinitytest (altinity build)) 2025.07.28 11:54:02.790059 [ 5951 ] {} 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. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::NetException::NetException(int, T&&) @ 0x0000000016900f80 3. /build/src/Server/TCPHandler.cpp:2426: DB::TCPHandler::receivePacketsExpectCancel(DB::QueryState&) @ 0x00000000168fba18 4. /build/src/Server/TCPHandler.cpp:1242: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x00000000168f1540 5. /build/src/Server/TCPHandler.cpp:678: DB::TCPHandler::runImpl() @ 0x00000000168e68e5 6. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 7. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 8. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 9. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 10. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 11. ? @ 0x00007fbc6213eac3 12. ? @ 0x00007fbc621d0850 2025.07.28 11:54:02.822856 [ 17208 ] {} TCPHandler: Code: 100. DB::Exception: Unknown packet 9223372036854775807 from server 127.0.0.2:9000: While executing Remote. (UNKNOWN_PACKET_FROM_SERVER), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String const&) @ 0x000000000a68756b 4. /build/src/Client/Connection.cpp:1323: DB::Connection::receivePacket() @ 0x00000000167db7d2 5. /build/src/Client/PacketReceiver.cpp:66: DB::PacketReceiver::Task::run(std::function, std::function) @ 0x0000000016819393 6. /build/src/Common/AsyncTaskExecutor.cpp:89: DB::AsyncTaskExecutor::Routine::operator()(std::function) @ 0x0000000013bd1892 7. /build/src/Common/Fiber.h:76: boost::context::detail::fiber_record>::run(void*) @ 0x0000000013bd16fa 8. /build/contrib/boost/boost/context/fiber_fcontext.hpp:97: void boost::context::detail::fiber_entry>>(boost::context::detail::transfer_t) @ 0x0000000013bd1621 Job's origin stack trace: 0. /build/src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000000fc33b84 1. /build/src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000000fcc2ea7 2. /build/src/Common/ThreadPool.cpp:401: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fcc7f1c 3. /build/src/Common/ThreadPool.cpp:494: ThreadPoolImpl>::scheduleOrThrowOnError(std::function, Priority) @ 0x000000000fcc7a0e 4. /build/src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::spawnThreadsImpl() @ 0x00000000169b2c0c 5. /build/src/Processors/Executors/PipelineExecutor.cpp:394: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x00000000169b0ba7 6. /build/src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x00000000169b03f4 7. /build/src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:se190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169bfeab 8. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc3d92 9. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fcca080 10. ? @ 0x00007fbc6213eac3 11. ? @ 0x00007fbc621d0850 Job's origin stack trace: 0. /build/src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000000fc33b84 1. /build/src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000000fcc2ea7 2. /build/src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fcc535c 3. /build/src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000000fcc584d 4. /build/src/Common/ThreadPool.h:279: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x00000000169bf193 5. /build/src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x00000000169bf518 6. /build/src/Server/TCPHandler.cpp:1237: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x00000000168f1525 7. /build/src/Server/TCPHandler.cpp:678: DB::TCPHandler::runImpl() @ 0x00000000168e68e5 8. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 9. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 10. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 11. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 12. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 13. ? @ 0x00007fbc6213eac3 14. ? @ 0x00007fbc621d0850 2025.07.28 11:54:02.840368 [ 4963 ] {59be97a7-7ffa-4441-b985-849fd18936eb} 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]:46644). (NETWORK_ERROR), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::NetException::NetException(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&) @ 0x000000000fd50fb5 3. /build/src/IO/WriteBufferFromPocoSocket.cpp:160: DB::WriteBufferFromPocoSocket::nextImpl() @ 0x000000000fd523f1 4. /build/src/IO/WriteBuffer.h:53: DB::WriteBuffer::next() @ 0x000000000a0755be 5. /build/src/Server/TCPHandler.cpp:2490: DB::TCPHandler::sendData(DB::QueryState&, DB::Block const&) @ 0x00000000168fa306 6. /build/src/Server/TCPHandler.cpp:1266: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x00000000168f162c 7. /build/src/Server/TCPHandler.cpp:678: DB::TCPHandler::runImpl() @ 0x00000000168e68e5 8. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 9. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 10. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 11. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 12. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 13. ? @ 0x00007fbc6213eac3 14. ? @ 0x00007fbc621d0850 (version 25.3.6.10636.altinitytest (altinity build)) 2025.07.28 11:54:02.844308 [ 4963 ] {59be97a7-7ffa-4441-b985-849fd18936eb} executeQuery: Code: 210. DB::NetException: Connection reset by peer, while writing to socket ([::ffff:127.0.0.3]:9000 -> [::ffff:127.0.0.1]:46644). (NETWORK_ERROR) (version 25.3.6.10636.altinitytest (altinity build)) (from [::ffff:127.0.0.1]:46644) (comment: 01822_async_read_from_socket_crash.sh) (query 1, line 1) (in query: SELECT `__table1`.`number` AS `number` FROM numbers(20) AS `__table1` LIMIT _CAST(8, 'UInt64')), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::NetException::NetException(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&) @ 0x000000000fd50fb5 3. /build/src/IO/WriteBufferFromPocoSocket.cpp:160: DB::WriteBufferFromPocoSocket::nextImpl() @ 0x000000000fd523f1 4. /build/src/IO/WriteBuffer.h:53: DB::WriteBuffer::next() @ 0x000000000a0755be 5. /build/src/Server/TCPHandler.cpp:2490: DB::TCPHandler::sendData(DB::QueryState&, DB::Block const&) @ 0x00000000168fa306 6. /build/src/Server/TCPHandler.cpp:1266: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x00000000168f162c 7. /build/src/Server/TCPHandler.cpp:678: DB::TCPHandler::runImpl() @ 0x00000000168e68e5 8. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 9. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 10. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 11. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 12. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 13. ? @ 0x00007fbc6213eac3 14. ? @ 0x00007fbc621d0850 2025.07.28 11:54:02.848929 [ 4963 ] {} TCPHandler: Code: 210. DB::NetException: Connection reset by peer, while writing to socket ([::ffff:127.0.0.3]:9000 -> [::ffff:127.0.0.1]:46644). (NETWORK_ERROR), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::NetException::NetException(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&) @ 0x000000000fd50fb5 3. /build/src/IO/WriteBufferFromPocoSocket.cpp:160: DB::WriteBufferFromPocoSocket::nextImpl() @ 0x000000000fd523f1 4. /build/src/IO/WriteBuffer.h:53: DB::WriteBuffer::next() @ 0x000000000a0755be 5. /build/src/Server/TCPHandler.cpp:2490: DB::TCPHandler::sendData(DB::QueryState&, DB::Block const&) @ 0x00000000168fa306 6. /build/src/Server/TCPHandler.cpp:1266: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x00000000168f162c 7. /build/src/Server/TCPHandler.cpp:678: DB::TCPHandler::runImpl() @ 0x00000000168e68e5 8. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 9. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 10. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 11. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 12. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 13. ? @ 0x00007fbc6213eac3 14. ? @ 0x00007fbc621d0850 2025.07.28 11:54:03.091852 [ 17252 ] {6692a72a-c612-4c04-8ab5-8da4aa3dbfe7} executeQuery: Code: 47. DB::Exception: Unknown expression or function identifier `value` in scope SELECT sum(value) FROM test_alter_on_mutation. Maybe you meant: ['value1']. (UNKNOWN_IDENTIFIER) (version 25.3.6.10636.altinitytest (altinity build)) (from [::1]:60330) (comment: 01062_alter_on_mutataion_zookeeper_long.sql) (query 21, line 48) (in query: SELECT sum(value) from test_alter_on_mutation;), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.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&&) @ 0x000000001404b3b9 4. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3771: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000001401b849 5. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3980: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000014018e31 6. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:2925: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000001402fcbd 7. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3838: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000014019a9e 8. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3980: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000014018e31 9. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:4304: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000014042fa7 10. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5605: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000014013749 11. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000140127f9 12. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000014011fce 13. /build/src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000001406ce8a 14. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000014973b42 15. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000001497268d 16. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000014974d24 17. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001492924b 18. /build/src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88641 19. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 20. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 21. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 22. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 23. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 24. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 25. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 26. ? @ 0x00007fbc6213eac3 27. ? @ 0x00007fbc621d0850 2025.07.28 11:54:03.109645 [ 17252 ] {} TCPHandler: Code: 47. DB::Exception: Unknown expression or function identifier `value` in scope SELECT sum(value) FROM test_alter_on_mutation. Maybe you meant: ['value1']. (UNKNOWN_IDENTIFIER), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.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&&) @ 0x000000001404b3b9 4. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3771: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000001401b849 5. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3980: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000014018e31 6. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:2925: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000001402fcbd 7. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3838: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000014019a9e 8. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3980: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000014018e31 9. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:4304: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000014042fa7 10. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5605: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000014013749 11. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000140127f9 12. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000014011fce 13. /build/src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000001406ce8a 14. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000014973b42 15. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000001497268d 16. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000014974d24 17. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001492924b 18. /build/src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88641 19. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 20. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 21. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 22. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 23. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 24. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 25. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 26. ? @ 0x00007fbc6213eac3 27. ? @ 0x00007fbc621d0850 2025.07.28 11:54:03.600494 [ 17207 ] {644ccb1d-c32a-46d1-9baa-9a82350f3c1f} executeQuery: Code: 62. DB::Exception: Cannot TRUNCATE dictionary. (SYNTAX_ERROR) (version 25.3.6.10636.altinitytest (altinity build)) (from [::1]:60392) (comment: 02099_hashed_array_dictionary_complex_key.gen.sql) (query 22, line 48) (in query: DROP DICTIONARY hashed_array_dictionary_complex_key_simple_attributes;), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000000a074fcb 4. /build/src/Interpreters/InterpreterDropQuery.cpp:266: DB::InterpreterDropQuery::executeToTableImpl(std::shared_ptr const&, DB::ASTDropQuery&, std::shared_ptr&, StrongTypedef, DB::UUIDTag>&) @ 0x0000000014915b7b 5. /build/src/Interpreters/InterpreterDropQuery.cpp:118: DB::InterpreterDropQuery::executeToTable(DB::ASTDropQuery&) @ 0x00000000149137b4 6. /build/src/Interpreters/InterpreterDropQuery.cpp:91: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000014912f07 7. /build/src/Interpreters/InterpreterDropQuery.cpp:72: DB::InterpreterDropQuery::execute() @ 0x0000000014912b65 8. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88dc9 9. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 10. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 11. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 12. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 13. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 14. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 15. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 16. ? @ 0x00007fbc6213eac3 17. ? @ 0x00007fbc621d0850 2025.07.28 11:54:03.607927 [ 17207 ] {} TCPHandler: Code: 62. DB::Exception: Cannot TRUNCATE dictionary. (SYNTAX_ERROR), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000000a074fcb 4. /build/src/Interpreters/InterpreterDropQuery.cpp:266: DB::InterpreterDropQuery::executeToTableImpl(std::shared_ptr const&, DB::ASTDropQuery&, std::shared_ptr&, StrongTypedef, DB::UUIDTag>&) @ 0x0000000014915b7b 5. /build/src/Interpreters/InterpreterDropQuery.cpp:118: DB::InterpreterDropQuery::executeToTable(DB::ASTDropQuery&) @ 0x00000000149137b4 6. /build/src/Interpreters/InterpreterDropQuery.cpp:91: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000014912f07 7. /build/src/Interpreters/InterpreterDropQuery.cpp:72: DB::InterpreterDropQuery::execute() @ 0x0000000014912b65 8. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88dc9 9. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 10. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 11. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 12. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 13. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 14. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 15. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 16. ? @ 0x00007fbc6213eac3 17. ? @ 0x00007fbc621d0850 2025.07.28 11:54:03.746217 [ 3966 ] {} test_13.rmt2 (7f9b740d-015c-470e-8cc6-8ba33be0dc63): auto DB::StorageReplicatedMergeTree::processQueueEntry(ReplicatedMergeTreeQueue::SelectedEntryPtr)::(anonymous class)::operator()(LogEntryPtr &) const: Code: 86. DB::HTTPException: Received error from remote server http://146b4357c08d:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Ftest%2F01165%2Ftest_13%2Frmt%2Freplicas%2F1&part=20250728_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.6.10636.altinitytest (altinity build)) '. (RECEIVED_ERROR_FROM_REMOTE_IO_SERVER), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.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 const&, int&&, String const&, unsigned long&&, String const&) @ 0x000000000feda8d9 4. /build/src/IO/HTTPCommon.cpp:104: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x000000000feda6e2 5. /build/src/IO/HTTPCommon.cpp:93: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x000000000feda537 6. /build/src/IO/ReadWriteBufferFromHTTP.cpp:277: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x000000001184a4c4 7. /build/src/IO/ReadWriteBufferFromHTTP.cpp:285: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x000000001184a615 8. /build/src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x000000001184ae59 9. /build/src/IO/ReadWriteBufferFromHTTP.cpp:472: void std::__function::__policy_invoker::__call_impl[abi:se190107]>(std::__function::__policy_storage const*) @ 0x000000001184cedd 10. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001184858b 11. /build/src/IO/ReadWriteBufferFromHTTP.cpp:465: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x000000001184bf0b 12. /build/src/IO/ReadBuffer.h:60: DB::ReadBuffer::next() @ 0x000000000a148c7b 13. /build/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) @ 0x0000000011849fb2 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]>&)>&, 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&) @ 0x0000000011841980 15. /build/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) @ 0x000000001621208e 16. /build/src/Storages/StorageReplicatedMergeTree.cpp:5228: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl[abi:se190107] const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000015f9a5fe 17. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000015ed8bfd 18. /build/src/Storages/StorageReplicatedMergeTree.cpp:2514: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x0000000015ec9aab 19. /build/src/Storages/StorageReplicatedMergeTree.cpp:2349: DB::StorageReplicatedMergeTree::executeLogEntry(DB::ReplicatedMergeTreeLogEntry&) @ 0x0000000015eba91b 20. /build/src/Storages/StorageReplicatedMergeTree.cpp:3876: bool std::__function::__policy_invoker&)>::__call_impl[abi:se190107])::$_1, bool (std::shared_ptr&)>>(std::__function::__policy_storage const*, std::shared_ptr&) @ 0x0000000015f9837e 21. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000165d6fc3 22. /build/src/Storages/StorageReplicatedMergeTree.cpp:3872: DB::StorageReplicatedMergeTree::processQueueEntry(std::shared_ptr) @ 0x0000000015efc18a 23. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001624c1b2 24. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000162f9c70 25. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x00000000162fa55a 26. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc6653 27. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000000fccc4c3 28. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc3d92 29. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fcca080 30. ? @ 0x00007fbc6213eac3 31. ? @ 0x00007fbc621d0850 (version 25.3.6.10636.altinitytest (altinity build)) 2025.07.28 11:54:04.285748 [ 3963 ] {} test_13.rmt2 (7f9b740d-015c-470e-8cc6-8ba33be0dc63): auto DB::StorageReplicatedMergeTree::processQueueEntry(ReplicatedMergeTreeQueue::SelectedEntryPtr)::(anonymous class)::operator()(LogEntryPtr &) const: Code: 86. DB::HTTPException: Received error from remote server http://146b4357c08d:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Ftest%2F01165%2Ftest_13%2Frmt%2Freplicas%2F1&part=20250728_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.6.10636.altinitytest (altinity build)) '. (RECEIVED_ERROR_FROM_REMOTE_IO_SERVER), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.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 const&, int&&, String const&, unsigned long&&, String const&) @ 0x000000000feda8d9 4. /build/src/IO/HTTPCommon.cpp:104: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x000000000feda6e2 5. /build/src/IO/HTTPCommon.cpp:93: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x000000000feda537 6. /build/src/IO/ReadWriteBufferFromHTTP.cpp:277: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x000000001184a4c4 7. /build/src/IO/ReadWriteBufferFromHTTP.cpp:285: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x000000001184a615 8. /build/src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x000000001184ae59 9. /build/src/IO/ReadWriteBufferFromHTTP.cpp:472: void std::__function::__policy_invoker::__call_impl[abi:se190107]>(std::__function::__policy_storage const*) @ 0x000000001184cedd 10. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001184858b 11. /build/src/IO/ReadWriteBufferFromHTTP.cpp:465: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x000000001184bf0b 12. /build/src/IO/ReadBuffer.h:60: DB::ReadBuffer::next() @ 0x000000000a148c7b 13. /build/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) @ 0x0000000011849fb2 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]>&)>&, 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&) @ 0x0000000011841980 15. /build/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) @ 0x000000001621208e 16. /build/src/Storages/StorageReplicatedMergeTree.cpp:5228: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl[abi:se190107] const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000015f9a5fe 17. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000015ed8bfd 18. /build/src/Storages/StorageReplicatedMergeTree.cpp:2514: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x0000000015ec9aab 19. /build/src/Storages/StorageReplicatedMergeTree.cpp:2349: DB::StorageReplicatedMergeTree::executeLogEntry(DB::ReplicatedMergeTreeLogEntry&) @ 0x0000000015eba91b 20. /build/src/Storages/StorageReplicatedMergeTree.cpp:3876: bool std::__function::__policy_invoker&)>::__call_impl[abi:se190107])::$_1, bool (std::shared_ptr&)>>(std::__function::__policy_storage const*, std::shared_ptr&) @ 0x0000000015f9837e 21. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000165d6fc3 22. /build/src/Storages/StorageReplicatedMergeTree.cpp:3872: DB::StorageReplicatedMergeTree::processQueueEntry(std::shared_ptr) @ 0x0000000015efc18a 23. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001624c1b2 24. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000162f9c70 25. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x00000000162fa55a 26. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc6653 27. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000000fccc4c3 28. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc3d92 29. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fcca080 30. ? @ 0x00007fbc6213eac3 31. ? @ 0x00007fbc621d0850 (version 25.3.6.10636.altinitytest (altinity build)) 2025.07.28 11:54:06.778624 [ 5327 ] {f586197d-34b6-419e-92c3-c5412a4a5ea5} executeQuery: Code: 153. DB::Exception: Division by zero: while executing 'FUNCTION modulo(1_UInt8 :: 1, modulo(plus(__table1.number, 500_UInt16), 1000_UInt16) :: 2) -> modulo(1_UInt8, modulo(plus(__table1.number, 500_UInt16), 1000_UInt16)) UInt16 : 3'. (ILLEGAL_DIVISION) (version 25.3.6.10636.altinitytest (altinity build)) (from [::1]:60610) (comment: 00093_union_race_conditions_4.sh) (query 1, line 1) (in query: SELECT 1 % ((number + 500) % 1000) FROM numbers_mt(1000);), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000000a074fcb 4. /build/src/Functions/DivisionUtils.h:26: void DB::impl_::BinaryOperation, unsigned short>::process<(DB::impl_::OpCase)1>(char8_t const*, unsigned short const*, unsigned short*, unsigned long, DB::PODArray, 63ul, 64ul> const*) @ 0x000000000d184621 5. /build/src/Functions/FunctionBinaryArithmetic.h:2338: COW::immutable_ptr DB::FunctionBinaryArithmetic::executeNumeric, DB::DataTypeNumber>(std::vector> const&, DB::DataTypeNumber const&, DB::DataTypeNumber const&, DB::PODArray, 63ul, 64ul> const*) const @ 0x000000000d3a6416 6. /build/src/Functions/FunctionBinaryArithmetic.h:2508: 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&&) @ 0x000000000d3a4a68 7. /build/src/Functions/FunctionBinaryArithmetic.h:846: 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&&) @ 0x000000000d3a3ec7 8. /build/src/Functions/FunctionBinaryArithmetic.h:844: DB::FunctionBinaryArithmetic::executeImpl2(std::vector> const&, std::shared_ptr const&, unsigned long, DB::PODArray, 63ul, 64ul> const*) const @ 0x000000000d3a03c5 9. /build/src/Functions/FunctionBinaryArithmetic.h:2410: DB::FunctionBinaryArithmetic::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000d39e94c 10. /build/src/Functions/FunctionBinaryArithmetic.h:2645: DB::FunctionBinaryArithmeticWithConstants::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000d39dbd4 11. /build/src/Functions/IFunctionAdaptors.cpp:10: DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000012d995fa 12. /build/src/Functions/IFunction.cpp:353: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d93b52 13. /build/src/Functions/IFunction.cpp:420: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d95059 14. /build/src/Functions/IFunction.cpp:498: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d95c72 15. /build/src/Interpreters/ExpressionActions.cpp:636: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x00000000145176f3 16. /build/src/Processors/Transforms/ExpressionTransform.cpp:25: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x0000000016c0b34c 17. /build/src/Processors/ISimpleTransform.h:33: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000011a9a453 18. /build/src/Processors/ISimpleTransform.cpp:89: DB::ISimpleTransform::work() @ 0x000000001699fca0 19. /build/src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x00000000169bd00f 20. /build/src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x00000000169b2105 21. /build/src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeSingleThread(unsigned long) @ 0x00000000169b23be 22. /build/src/Processors/Executors/PipelineExecutor.cpp:454: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x00000000169b0be7 23. /build/src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x00000000169b03f4 24. /build/src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:se190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169bfeab 25. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc3d92 26. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fcca080 27. ? @ 0x00007fbc6213eac3 28. ? @ 0x00007fbc621d0850 2025.07.28 11:54:06.798083 [ 3964 ] {} test_13.rmt2 (7f9b740d-015c-470e-8cc6-8ba33be0dc63): auto DB::StorageReplicatedMergeTree::processQueueEntry(ReplicatedMergeTreeQueue::SelectedEntryPtr)::(anonymous class)::operator()(LogEntryPtr &) const: Code: 86. DB::HTTPException: Received error from remote server http://146b4357c08d:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Ftest%2F01165%2Ftest_13%2Frmt%2Freplicas%2F1&part=20250728_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.6.10636.altinitytest (altinity build)) '. (RECEIVED_ERROR_FROM_REMOTE_IO_SERVER), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.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 const&, int&&, String const&, unsigned long&&, String const&) @ 0x000000000feda8d9 4. /build/src/IO/HTTPCommon.cpp:104: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x000000000feda6e2 5. /build/src/IO/HTTPCommon.cpp:93: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x000000000feda537 6. /build/src/IO/ReadWriteBufferFromHTTP.cpp:277: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x000000001184a4c4 7. /build/src/IO/ReadWriteBufferFromHTTP.cpp:285: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x000000001184a615 8. /build/src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x000000001184ae59 9. /build/src/IO/ReadWriteBufferFromHTTP.cpp:472: void std::__function::__policy_invoker::__call_impl[abi:se190107]>(std::__function::__policy_storage const*) @ 0x000000001184cedd 10. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001184858b 11. /build/src/IO/ReadWriteBufferFromHTTP.cpp:465: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x000000001184bf0b 12. /build/src/IO/ReadBuffer.h:60: DB::ReadBuffer::next() @ 0x000000000a148c7b 13. /build/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) @ 0x0000000011849fb2 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]>&)>&, 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&) @ 0x0000000011841980 15. /build/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) @ 0x000000001621208e 16. /build/src/Storages/StorageReplicatedMergeTree.cpp:5228: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl[abi:se190107] const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000015f9a5fe 17. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000015ed8bfd 18. /build/src/Storages/StorageReplicatedMergeTree.cpp:2514: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x0000000015ec9aab 19. /build/src/Storages/StorageReplicatedMergeTree.cpp:2349: DB::StorageReplicatedMergeTree::executeLogEntry(DB::ReplicatedMergeTreeLogEntry&) @ 0x0000000015eba91b 20. /build/src/Storages/StorageReplicatedMergeTree.cpp:3876: bool std::__function::__policy_invoker&)>::__call_impl[abi:se190107])::$_1, bool (std::shared_ptr&)>>(std::__function::__policy_storage const*, std::shared_ptr&) @ 0x0000000015f9837e 21. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000165d6fc3 22. /build/src/Storages/StorageReplicatedMergeTree.cpp:3872: DB::StorageReplicatedMergeTree::processQueueEntry(std::shared_ptr) @ 0x0000000015efc18a 23. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001624c1b2 24. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000162f9c70 25. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x00000000162fa55a 26. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc6653 27. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000000fccc4c3 28. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc3d92 29. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fcca080 30. ? @ 0x00007fbc6213eac3 31. ? @ 0x00007fbc621d0850 (version 25.3.6.10636.altinitytest (altinity build)) 2025.07.28 11:54:06.824655 [ 5327 ] {} TCPHandler: Code: 153. DB::Exception: Division by zero: while executing 'FUNCTION modulo(1_UInt8 :: 1, modulo(plus(__table1.number, 500_UInt16), 1000_UInt16) :: 2) -> modulo(1_UInt8, modulo(plus(__table1.number, 500_UInt16), 1000_UInt16)) UInt16 : 3'. (ILLEGAL_DIVISION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000000a074fcb 4. /build/src/Functions/DivisionUtils.h:26: void DB::impl_::BinaryOperation, unsigned short>::process<(DB::impl_::OpCase)1>(char8_t const*, unsigned short const*, unsigned short*, unsigned long, DB::PODArray, 63ul, 64ul> const*) @ 0x000000000d184621 5. /build/src/Functions/FunctionBinaryArithmetic.h:2338: COW::immutable_ptr DB::FunctionBinaryArithmetic::executeNumeric, DB::DataTypeNumber>(std::vector> const&, DB::DataTypeNumber const&, DB::DataTypeNumber const&, DB::PODArray, 63ul, 64ul> const*) const @ 0x000000000d3a6416 6. /build/src/Functions/FunctionBinaryArithmetic.h:2508: 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&&) @ 0x000000000d3a4a68 7. /build/src/Functions/FunctionBinaryArithmetic.h:846: 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&&) @ 0x000000000d3a3ec7 8. /build/src/Functions/FunctionBinaryArithmetic.h:844: DB::FunctionBinaryArithmetic::executeImpl2(std::vector> const&, std::shared_ptr const&, unsigned long, DB::PODArray, 63ul, 64ul> const*) const @ 0x000000000d3a03c5 9. /build/src/Functions/FunctionBinaryArithmetic.h:2410: DB::FunctionBinaryArithmetic::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000d39e94c 10. /build/src/Functions/FunctionBinaryArithmetic.h:2645: DB::FunctionBinaryArithmeticWithConstants::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000d39dbd4 11. /build/src/Functions/IFunctionAdaptors.cpp:10: DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000012d995fa 12. /build/src/Functions/IFunction.cpp:353: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d93b52 13. /build/src/Functions/IFunction.cpp:420: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d95059 14. /build/src/Functions/IFunction.cpp:498: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d95c72 15. /build/src/Interpreters/ExpressionActions.cpp:636: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x00000000145176f3 16. /build/src/Processors/Transforms/ExpressionTransform.cpp:25: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x0000000016c0b34c 17. /build/src/Processors/ISimpleTransform.h:33: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000011a9a453 18. /build/src/Processors/ISimpleTransform.cpp:89: DB::ISimpleTransform::work() @ 0x000000001699fca0 19. /build/src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x00000000169bd00f 20. /build/src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x00000000169b2105 21. /build/src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeSingleThread(unsigned long) @ 0x00000000169b23be 22. /build/src/Processors/Executors/PipelineExecutor.cpp:454: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x00000000169b0be7 23. /build/src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x00000000169b03f4 24. /build/src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:se190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169bfeab 25. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc3d92 26. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fcca080 27. ? @ 0x00007fbc6213eac3 28. ? @ 0x00007fbc621d0850 Job's origin stack trace: 0. /build/src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000000fc33b84 1. /build/src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000000fcc2ea7 2. /build/src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fcc535c 3. /build/src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000000fcc584d 4. /build/src/Common/ThreadPool.h:279: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x00000000169bf193 5. /build/src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x00000000169bf518 6. /build/src/Server/TCPHandler.cpp:1237: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x00000000168f1525 7. /build/src/Server/TCPHandler.cpp:678: DB::TCPHandler::runImpl() @ 0x00000000168e68e5 8. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 9. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 10. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 11. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 12. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 13. ? @ 0x00007fbc6213eac3 14. ? @ 0x00007fbc621d0850 2025.07.28 11:54:07.118906 [ 3961 ] {} test_13.rmt2 (7f9b740d-015c-470e-8cc6-8ba33be0dc63): auto DB::StorageReplicatedMergeTree::processQueueEntry(ReplicatedMergeTreeQueue::SelectedEntryPtr)::(anonymous class)::operator()(LogEntryPtr &) const: Code: 86. DB::HTTPException: Received error from remote server http://146b4357c08d:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Ftest%2F01165%2Ftest_13%2Frmt%2Freplicas%2F1&part=20250728_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.6.10636.altinitytest (altinity build)) '. (RECEIVED_ERROR_FROM_REMOTE_IO_SERVER), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.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 const&, int&&, String const&, unsigned long&&, String const&) @ 0x000000000feda8d9 4. /build/src/IO/HTTPCommon.cpp:104: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x000000000feda6e2 5. /build/src/IO/HTTPCommon.cpp:93: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x000000000feda537 6. /build/src/IO/ReadWriteBufferFromHTTP.cpp:277: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x000000001184a4c4 7. /build/src/IO/ReadWriteBufferFromHTTP.cpp:285: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x000000001184a615 8. /build/src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x000000001184ae59 9. /build/src/IO/ReadWriteBufferFromHTTP.cpp:472: void std::__function::__policy_invoker::__call_impl[abi:se190107]>(std::__function::__policy_storage const*) @ 0x000000001184cedd 10. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001184858b 11. /build/src/IO/ReadWriteBufferFromHTTP.cpp:465: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x000000001184bf0b 12. /build/src/IO/ReadBuffer.h:60: DB::ReadBuffer::next() @ 0x000000000a148c7b 13. /build/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) @ 0x0000000011849fb2 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]>&)>&, 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&) @ 0x0000000011841980 15. /build/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) @ 0x000000001621208e 16. /build/src/Storages/StorageReplicatedMergeTree.cpp:5228: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl[abi:se190107] const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000015f9a5fe 17. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000015ed8bfd 18. /build/src/Storages/StorageReplicatedMergeTree.cpp:2514: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x0000000015ec9aab 19. /build/src/Storages/StorageReplicatedMergeTree.cpp:2349: DB::StorageReplicatedMergeTree::executeLogEntry(DB::ReplicatedMergeTreeLogEntry&) @ 0x0000000015eba91b 20. /build/src/Storages/StorageReplicatedMergeTree.cpp:3876: bool std::__function::__policy_invoker&)>::__call_impl[abi:se190107])::$_1, bool (std::shared_ptr&)>>(std::__function::__policy_storage const*, std::shared_ptr&) @ 0x0000000015f9837e 21. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000165d6fc3 22. /build/src/Storages/StorageReplicatedMergeTree.cpp:3872: DB::StorageReplicatedMergeTree::processQueueEntry(std::shared_ptr) @ 0x0000000015efc18a 23. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001624c1b2 24. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000162f9c70 25. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x00000000162fa55a 26. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc6653 27. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000000fccc4c3 28. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc3d92 29. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fcca080 30. ? @ 0x00007fbc6213eac3 31. ? @ 0x00007fbc621d0850 (version 25.3.6.10636.altinitytest (altinity build)) 2025.07.28 11:54:07.930921 [ 3962 ] {} test_13.rmt2 (7f9b740d-015c-470e-8cc6-8ba33be0dc63): auto DB::StorageReplicatedMergeTree::processQueueEntry(ReplicatedMergeTreeQueue::SelectedEntryPtr)::(anonymous class)::operator()(LogEntryPtr &) const: Code: 86. DB::HTTPException: Received error from remote server http://146b4357c08d:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Ftest%2F01165%2Ftest_13%2Frmt%2Freplicas%2F1&part=20250728_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.6.10636.altinitytest (altinity build)) '. (RECEIVED_ERROR_FROM_REMOTE_IO_SERVER), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.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 const&, int&&, String const&, unsigned long&&, String const&) @ 0x000000000feda8d9 4. /build/src/IO/HTTPCommon.cpp:104: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x000000000feda6e2 5. /build/src/IO/HTTPCommon.cpp:93: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x000000000feda537 6. /build/src/IO/ReadWriteBufferFromHTTP.cpp:277: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x000000001184a4c4 7. /build/src/IO/ReadWriteBufferFromHTTP.cpp:285: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x000000001184a615 8. /build/src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x000000001184ae59 9. /build/src/IO/ReadWriteBufferFromHTTP.cpp:472: void std::__function::__policy_invoker::__call_impl[abi:se190107]>(std::__function::__policy_storage const*) @ 0x000000001184cedd 10. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001184858b 11. /build/src/IO/ReadWriteBufferFromHTTP.cpp:465: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x000000001184bf0b 12. /build/src/IO/ReadBuffer.h:60: DB::ReadBuffer::next() @ 0x000000000a148c7b 13. /build/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) @ 0x0000000011849fb2 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]>&)>&, 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&) @ 0x0000000011841980 15. /build/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) @ 0x000000001621208e 16. /build/src/Storages/StorageReplicatedMergeTree.cpp:5228: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl[abi:se190107] const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000015f9a5fe 17. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000015ed8bfd 18. /build/src/Storages/StorageReplicatedMergeTree.cpp:2514: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x0000000015ec9aab 19. /build/src/Storages/StorageReplicatedMergeTree.cpp:2349: DB::StorageReplicatedMergeTree::executeLogEntry(DB::ReplicatedMergeTreeLogEntry&) @ 0x0000000015eba91b 20. /build/src/Storages/StorageReplicatedMergeTree.cpp:3876: bool std::__function::__policy_invoker&)>::__call_impl[abi:se190107])::$_1, bool (std::shared_ptr&)>>(std::__function::__policy_storage const*, std::shared_ptr&) @ 0x0000000015f9837e 21. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000165d6fc3 22. /build/src/Storages/StorageReplicatedMergeTree.cpp:3872: DB::StorageReplicatedMergeTree::processQueueEntry(std::shared_ptr) @ 0x0000000015efc18a 23. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001624c1b2 24. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000162f9c70 25. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x00000000162fa55a 26. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc6653 27. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000000fccc4c3 28. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc3d92 29. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fcca080 30. ? @ 0x00007fbc6213eac3 31. ? @ 0x00007fbc621d0850 (version 25.3.6.10636.altinitytest (altinity build)) 2025.07.28 11:54:08.670025 [ 3960 ] {} test_13.rmt2 (7f9b740d-015c-470e-8cc6-8ba33be0dc63): auto DB::StorageReplicatedMergeTree::processQueueEntry(ReplicatedMergeTreeQueue::SelectedEntryPtr)::(anonymous class)::operator()(LogEntryPtr &) const: Code: 86. DB::HTTPException: Received error from remote server http://146b4357c08d:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Ftest%2F01165%2Ftest_13%2Frmt%2Freplicas%2F1&part=20250728_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.6.10636.altinitytest (altinity build)) '. (RECEIVED_ERROR_FROM_REMOTE_IO_SERVER), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.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 const&, int&&, String const&, unsigned long&&, String const&) @ 0x000000000feda8d9 4. /build/src/IO/HTTPCommon.cpp:104: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x000000000feda6e2 5. /build/src/IO/HTTPCommon.cpp:93: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x000000000feda537 6. /build/src/IO/ReadWriteBufferFromHTTP.cpp:277: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x000000001184a4c4 7. /build/src/IO/ReadWriteBufferFromHTTP.cpp:285: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x000000001184a615 8. /build/src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x000000001184ae59 9. /build/src/IO/ReadWriteBufferFromHTTP.cpp:472: void std::__function::__policy_invoker::__call_impl[abi:se190107]>(std::__function::__policy_storage const*) @ 0x000000001184cedd 10. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001184858b 11. /build/src/IO/ReadWriteBufferFromHTTP.cpp:465: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x000000001184bf0b 12. /build/src/IO/ReadBuffer.h:60: DB::ReadBuffer::next() @ 0x000000000a148c7b 13. /build/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) @ 0x0000000011849fb2 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]>&)>&, 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&) @ 0x0000000011841980 15. /build/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) @ 0x000000001621208e 16. /build/src/Storages/StorageReplicatedMergeTree.cpp:5228: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl[abi:se190107] const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000015f9a5fe 17. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000015ed8bfd 18. /build/src/Storages/StorageReplicatedMergeTree.cpp:2514: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x0000000015ec9aab 19. /build/src/Storages/StorageReplicatedMergeTree.cpp:2349: DB::StorageReplicatedMergeTree::executeLogEntry(DB::ReplicatedMergeTreeLogEntry&) @ 0x0000000015eba91b 20. /build/src/Storages/StorageReplicatedMergeTree.cpp:3876: bool std::__function::__policy_invoker&)>::__call_impl[abi:se190107])::$_1, bool (std::shared_ptr&)>>(std::__function::__policy_storage const*, std::shared_ptr&) @ 0x0000000015f9837e 21. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000165d6fc3 22. /build/src/Storages/StorageReplicatedMergeTree.cpp:3872: DB::StorageReplicatedMergeTree::processQueueEntry(std::shared_ptr) @ 0x0000000015efc18a 23. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001624c1b2 24. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000162f9c70 25. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x00000000162fa55a 26. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc6653 27. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000000fccc4c3 28. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc3d92 29. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fcca080 30. ? @ 0x00007fbc6213eac3 31. ? @ 0x00007fbc621d0850 (version 25.3.6.10636.altinitytest (altinity build)) 2025.07.28 11:54:09.448753 [ 4581 ] {88a7f302-06cf-4c3b-842d-1aa5bf9c534a} executeQuery: Code: 57. DB::Exception: Table test_5.t1 already exists. (TABLE_ALREADY_EXISTS) (version 25.3.6.10636.altinitytest (altinity build)) (from 0.0.0.0:0) (comment: 03255_parallel_replicas_join_algo_and_analyzer_4.sh) (in query: /* ddl_entry=query-0000000075 */ CREATE TABLE test_5.t1 UUID 'b614e826-6eee-4aab-b640-caac4421ec62' (`item_id` UInt64, `price_sold` Float32, `date` Date) ENGINE = MergeTree ORDER BY item_id), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000a06a8eb 4. /build/src/Interpreters/InterpreterCreateQuery.cpp:1824: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x0000000014901d53 5. /build/src/Interpreters/InterpreterCreateQuery.cpp:1743: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000148f9aa9 6. /build/src/Interpreters/InterpreterCreateQuery.cpp:2352: DB::InterpreterCreateQuery::execute() @ 0x0000000014905a41 7. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88dc9 8. /build/src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x0000000014c8ca7b 9. /build/src/Interpreters/DDLWorker.cpp:510: DB::DDLWorker::tryExecuteQuery(DB::DDLTaskBase&, std::shared_ptr const&, bool) @ 0x00000000144dab9e 10. /build/src/Interpreters/DDLWorker.cpp:675: DB::DDLWorker::processTask(DB::DDLTaskBase&, std::shared_ptr const&, bool) @ 0x00000000144d8ffe 11. /build/src/Databases/DatabaseReplicatedWorker.cpp:372: DB::DatabaseReplicatedDDLWorker::tryEnqueueAndExecuteEntry(DB::DDLLogEntry&, std::shared_ptr, bool) @ 0x0000000013dc29ab 12. /build/src/Databases/DatabaseReplicated.cpp:1139: DB::DatabaseReplicated::tryEnqueueReplicatedDDL(std::shared_ptr const&, std::shared_ptr, DB::QueryFlags) @ 0x0000000013d9f73c 13. /build/src/Interpreters/InterpreterCreateQuery.cpp:1723: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000148f96f8 14. /build/src/Interpreters/InterpreterCreateQuery.cpp:2352: DB::InterpreterCreateQuery::execute() @ 0x0000000014905a41 15. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88dc9 16. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 17. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 18. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 19. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 20. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 21. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 22. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 23. ? @ 0x00007fbc6213eac3 24. ? @ 0x00007fbc621d0850 2025.07.28 11:54:09.468282 [ 4581 ] {88a7f302-06cf-4c3b-842d-1aa5bf9c534a} executeQuery: Code: 57. DB::Exception: Table test_5.t1 already exists. (TABLE_ALREADY_EXISTS) (version 25.3.6.10636.altinitytest (altinity build)) (from [::1]:35966) (comment: 03255_parallel_replicas_join_algo_and_analyzer_4.sh) (query 2, line 11) (in query: CREATE TABLE t1 ( item_id UInt64, price_sold Float32, date Date ) ENGINE = MergeTree ORDER BY item_id;), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000a06a8eb 4. /build/src/Interpreters/InterpreterCreateQuery.cpp:1824: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x0000000014901d53 5. /build/src/Interpreters/InterpreterCreateQuery.cpp:1743: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000148f9aa9 6. /build/src/Interpreters/InterpreterCreateQuery.cpp:2352: DB::InterpreterCreateQuery::execute() @ 0x0000000014905a41 7. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88dc9 8. /build/src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x0000000014c8ca7b 9. /build/src/Interpreters/DDLWorker.cpp:510: DB::DDLWorker::tryExecuteQuery(DB::DDLTaskBase&, std::shared_ptr const&, bool) @ 0x00000000144dab9e 10. /build/src/Interpreters/DDLWorker.cpp:675: DB::DDLWorker::processTask(DB::DDLTaskBase&, std::shared_ptr const&, bool) @ 0x00000000144d8ffe 11. /build/src/Databases/DatabaseReplicatedWorker.cpp:372: DB::DatabaseReplicatedDDLWorker::tryEnqueueAndExecuteEntry(DB::DDLLogEntry&, std::shared_ptr, bool) @ 0x0000000013dc29ab 12. /build/src/Databases/DatabaseReplicated.cpp:1139: DB::DatabaseReplicated::tryEnqueueReplicatedDDL(std::shared_ptr const&, std::shared_ptr, DB::QueryFlags) @ 0x0000000013d9f73c 13. /build/src/Interpreters/InterpreterCreateQuery.cpp:1723: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000148f96f8 14. /build/src/Interpreters/InterpreterCreateQuery.cpp:2352: DB::InterpreterCreateQuery::execute() @ 0x0000000014905a41 15. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88dc9 16. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 17. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 18. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 19. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 20. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 21. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 22. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 23. ? @ 0x00007fbc6213eac3 24. ? @ 0x00007fbc621d0850 2025.07.28 11:54:09.477084 [ 4581 ] {} TCPHandler: Code: 57. DB::Exception: Table test_5.t1 already exists. (TABLE_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000a06a8eb 4. /build/src/Interpreters/InterpreterCreateQuery.cpp:1824: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x0000000014901d53 5. /build/src/Interpreters/InterpreterCreateQuery.cpp:1743: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000148f9aa9 6. /build/src/Interpreters/InterpreterCreateQuery.cpp:2352: DB::InterpreterCreateQuery::execute() @ 0x0000000014905a41 7. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88dc9 8. /build/src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x0000000014c8ca7b 9. /build/src/Interpreters/DDLWorker.cpp:510: DB::DDLWorker::tryExecuteQuery(DB::DDLTaskBase&, std::shared_ptr const&, bool) @ 0x00000000144dab9e 10. /build/src/Interpreters/DDLWorker.cpp:675: DB::DDLWorker::processTask(DB::DDLTaskBase&, std::shared_ptr const&, bool) @ 0x00000000144d8ffe 11. /build/src/Databases/DatabaseReplicatedWorker.cpp:372: DB::DatabaseReplicatedDDLWorker::tryEnqueueAndExecuteEntry(DB::DDLLogEntry&, std::shared_ptr, bool) @ 0x0000000013dc29ab 12. /build/src/Databases/DatabaseReplicated.cpp:1139: DB::DatabaseReplicated::tryEnqueueReplicatedDDL(std::shared_ptr const&, std::shared_ptr, DB::QueryFlags) @ 0x0000000013d9f73c 13. /build/src/Interpreters/InterpreterCreateQuery.cpp:1723: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000148f96f8 14. /build/src/Interpreters/InterpreterCreateQuery.cpp:2352: DB::InterpreterCreateQuery::execute() @ 0x0000000014905a41 15. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88dc9 16. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 17. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 18. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 19. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 20. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 21. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 22. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 23. ? @ 0x00007fbc6213eac3 24. ? @ 0x00007fbc621d0850 2025.07.28 11:54:09.501538 [ 3972 ] {} test_13.rmt2 (7f9b740d-015c-470e-8cc6-8ba33be0dc63): auto DB::StorageReplicatedMergeTree::processQueueEntry(ReplicatedMergeTreeQueue::SelectedEntryPtr)::(anonymous class)::operator()(LogEntryPtr &) const: Code: 86. DB::HTTPException: Received error from remote server http://146b4357c08d:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Ftest%2F01165%2Ftest_13%2Frmt%2Freplicas%2F1&part=20250728_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.6.10636.altinitytest (altinity build)) '. (RECEIVED_ERROR_FROM_REMOTE_IO_SERVER), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.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 const&, int&&, String const&, unsigned long&&, String const&) @ 0x000000000feda8d9 4. /build/src/IO/HTTPCommon.cpp:104: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x000000000feda6e2 5. /build/src/IO/HTTPCommon.cpp:93: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x000000000feda537 6. /build/src/IO/ReadWriteBufferFromHTTP.cpp:277: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x000000001184a4c4 7. /build/src/IO/ReadWriteBufferFromHTTP.cpp:285: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x000000001184a615 8. /build/src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x000000001184ae59 9. /build/src/IO/ReadWriteBufferFromHTTP.cpp:472: void std::__function::__policy_invoker::__call_impl[abi:se190107]>(std::__function::__policy_storage const*) @ 0x000000001184cedd 10. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001184858b 11. /build/src/IO/ReadWriteBufferFromHTTP.cpp:465: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x000000001184bf0b 12. /build/src/IO/ReadBuffer.h:60: DB::ReadBuffer::next() @ 0x000000000a148c7b 13. /build/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) @ 0x0000000011849fb2 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]>&)>&, 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&) @ 0x0000000011841980 15. /build/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) @ 0x000000001621208e 16. /build/src/Storages/StorageReplicatedMergeTree.cpp:5228: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl[abi:se190107] const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000015f9a5fe 17. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000015ed8bfd 18. /build/src/Storages/StorageReplicatedMergeTree.cpp:2514: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x0000000015ec9aab 19. /build/src/Storages/StorageReplicatedMergeTree.cpp:2349: DB::StorageReplicatedMergeTree::executeLogEntry(DB::ReplicatedMergeTreeLogEntry&) @ 0x0000000015eba91b 20. /build/src/Storages/StorageReplicatedMergeTree.cpp:3876: bool std::__function::__policy_invoker&)>::__call_impl[abi:se190107])::$_1, bool (std::shared_ptr&)>>(std::__function::__policy_storage const*, std::shared_ptr&) @ 0x0000000015f9837e 21. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000165d6fc3 22. /build/src/Storages/StorageReplicatedMergeTree.cpp:3872: DB::StorageReplicatedMergeTree::processQueueEntry(std::shared_ptr) @ 0x0000000015efc18a 23. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001624c1b2 24. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000162f9c70 25. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x00000000162fa55a 26. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc6653 27. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000000fccc4c3 28. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc3d92 29. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fcca080 30. ? @ 0x00007fbc6213eac3 31. ? @ 0x00007fbc621d0850 (version 25.3.6.10636.altinitytest (altinity build)) 2025.07.28 11:54:09.851176 [ 5747 ] {24a606d7-3d11-43fd-8dbb-565a8d675a78} executeQuery: Code: 1. DB::Exception: Resolved identifier 'item_id' in parent scope to expression 'l.item_id' with correlated column 'item_id'. In scope SELECT item_id FROM t1. (UNSUPPORTED_METHOD) (version 25.3.6.10636.altinitytest (altinity build)) (from [::1]:36038) (comment: 03255_parallel_replicas_join_algo_and_analyzer_4.sh) (query 5, line 7) (in query: --SELECT '----- enable_parallel_replicas=0 prefer_local_plan=0 parallel_replicas_prefer_local_join=1 -----'; SELECT sum(item_id) FROM ( SELECT item_id FROM t GROUP BY item_id ) AS l LEFT JOIN ( SELECT item_id FROM t1 ) AS r ON l.item_id = r.item_id ;), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/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 const&, String&&) @ 0x000000001404a1eb 4. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:1382: DB::QueryAnalyzer::tryResolveIdentifierInParentScopes(DB::IdentifierLookup const&, DB::IdentifierResolveScope&, DB::IdentifierResolveContext) @ 0x000000001402a8cc 5. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:1544: DB::QueryAnalyzer::tryResolveIdentifier(DB::IdentifierLookup const&, DB::IdentifierResolveScope&, DB::IdentifierResolveContext) @ 0x00000000140298dd 6. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3692: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000001401a2b4 7. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3980: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000014018e31 8. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:4304: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000014042fa7 9. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5605: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000014013749 10. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3870: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x00000000140199de 11. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5334: DB::QueryAnalyzer::resolveQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&) @ 0x00000000140454b0 12. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5142: DB::QueryAnalyzer::resolveJoin(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&) @ 0x0000000014046de9 13. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5361: DB::QueryAnalyzer::resolveQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&) @ 0x00000000140452d6 14. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5597: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000140136f0 15. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000140127f9 16. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000014011fce 17. /build/src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000001406ce8a 18. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000014973b42 19. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000001497268d 20. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000014974d24 21. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001492924b 22. /build/src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88641 23. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 24. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 25. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 26. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 27. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 28. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 29. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 30. ? @ 0x00007fbc6213eac3 31. ? @ 0x00007fbc621d0850 2025.07.28 11:54:09.896272 [ 17210 ] {bd767253-bf6d-4750-bce6-f816e784a8cb} executeQuery: Code: 6. DB::Exception: Cannot parse string '1\'4' as UInt32: syntax error at position 1 (parsed just '1'). Note: there are toUInt32OrZero and toUInt32OrNull functions, which returns zero/NULL instead of throwing exception.: In scope SELECT CAST('1\'4', 'UInt32'). (CANNOT_PARSE_TEXT) (version 25.3.6.10636.altinitytest (altinity build)) (from [::1]:36058) (comment: 01852_cast_operator_bad_cases.sh) (query 1, line 1) (in query: SELECT '1''4'::UInt32), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Functions/FunctionsConversion.h:796: DB::detail::throwExceptionForIncompletelyParsedValue(DB::ReadBuffer&, DB::IDataType const&) @ 0x000000000a150a93 4. /build/src/Functions/FunctionsConversion.h:1042: COW::immutable_ptr DB::detail::ConvertThroughParsing, DB::detail::NameToUInt32, (DB::detail::ConvertFromStringExceptionMode)0, (DB::detail::ConvertFromStringParsingMode)0>::execute(std::vector> const&, std::shared_ptr const&, unsigned long, void*) @ 0x0000000012fed02a 5. /build/src/Functions/FunctionsConversion.h:1580: COW::immutable_ptr DB::detail::ConvertImpl, DB::detail::NameToUInt32, (DB::FormatSettings::DateTimeOverflowBehavior)0>::execute(std::vector> const&, std::shared_ptr const&, unsigned long, DB::detail::BehaviourOnErrorFromString, void*) @ 0x0000000012fecd1e 6. /build/src/Functions/FunctionsConversion.h:2472: 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&&) @ 0x0000000012f9cc64 7. /build/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 @ 0x0000000012fb122e 8. /build/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 @ 0x0000000012fb0a5a 9. /build/src/Functions/IFunctionAdaptors.cpp:10: DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000012d995fa 10. /build/src/Functions/IFunction.cpp:353: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d93b52 11. /build/src/Functions/IFunction.cpp:420: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d95059 12. /build/src/Functions/IFunction.cpp:498: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d95c72 13. /build/src/Functions/IFunction.cpp:513: DB::IFunctionBase::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d96059 14. /build/src/Functions/FunctionsConversion.h:3487: COW::immutable_ptr std::__function::__policy_invoker::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)>::__call_impl[abi:se190107], 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) @ 0x0000000012e00996 15. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000012ddcb1b 16. /build/src/Functions/IFunction.h:57: DB::IExecutableFunction::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000a08134a 17. /build/src/Functions/IFunction.cpp:351: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d93b02 18. /build/src/Functions/IFunction.cpp:177: DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d93698 19. /build/src/Functions/IFunction.cpp:343: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d93aad 20. /build/src/Functions/IFunction.cpp:424: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d94e1b 21. /build/src/Functions/IFunction.cpp:498: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d95c72 22. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3567: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000014034494 23. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3838: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000014019a9e 24. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3980: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000014018e31 25. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:4304: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000014042fa7 26. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5605: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000014013749 27. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000140127f9 28. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000014011fce 29. /build/src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000001406ce8a 30. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000014973b42 31. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000001497268d 2025.07.28 11:54:09.902405 [ 5747 ] {} TCPHandler: Code: 1. DB::Exception: Resolved identifier 'item_id' in parent scope to expression 'l.item_id' with correlated column 'item_id'. In scope SELECT item_id FROM t1. (UNSUPPORTED_METHOD), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/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 const&, String&&) @ 0x000000001404a1eb 4. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:1382: DB::QueryAnalyzer::tryResolveIdentifierInParentScopes(DB::IdentifierLookup const&, DB::IdentifierResolveScope&, DB::IdentifierResolveContext) @ 0x000000001402a8cc 5. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:1544: DB::QueryAnalyzer::tryResolveIdentifier(DB::IdentifierLookup const&, DB::IdentifierResolveScope&, DB::IdentifierResolveContext) @ 0x00000000140298dd 6. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3692: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000001401a2b4 7. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3980: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000014018e31 8. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:4304: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000014042fa7 9. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5605: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000014013749 10. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3870: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x00000000140199de 11. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5334: DB::QueryAnalyzer::resolveQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&) @ 0x00000000140454b0 12. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5142: DB::QueryAnalyzer::resolveJoin(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&) @ 0x0000000014046de9 13. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5361: DB::QueryAnalyzer::resolveQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&) @ 0x00000000140452d6 14. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5597: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000140136f0 15. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000140127f9 16. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000014011fce 17. /build/src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000001406ce8a 18. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000014973b42 19. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000001497268d 20. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000014974d24 21. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001492924b 22. /build/src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88641 23. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 24. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 25. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 26. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 27. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 28. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 29. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 30. ? @ 0x00007fbc6213eac3 31. ? @ 0x00007fbc621d0850 2025.07.28 11:54:09.926071 [ 17210 ] {} TCPHandler: Code: 6. DB::Exception: Cannot parse string '1\'4' as UInt32: syntax error at position 1 (parsed just '1'). Note: there are toUInt32OrZero and toUInt32OrNull functions, which returns zero/NULL instead of throwing exception.: In scope SELECT CAST('1\'4', 'UInt32'). (CANNOT_PARSE_TEXT), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Functions/FunctionsConversion.h:796: DB::detail::throwExceptionForIncompletelyParsedValue(DB::ReadBuffer&, DB::IDataType const&) @ 0x000000000a150a93 4. /build/src/Functions/FunctionsConversion.h:1042: COW::immutable_ptr DB::detail::ConvertThroughParsing, DB::detail::NameToUInt32, (DB::detail::ConvertFromStringExceptionMode)0, (DB::detail::ConvertFromStringParsingMode)0>::execute(std::vector> const&, std::shared_ptr const&, unsigned long, void*) @ 0x0000000012fed02a 5. /build/src/Functions/FunctionsConversion.h:1580: COW::immutable_ptr DB::detail::ConvertImpl, DB::detail::NameToUInt32, (DB::FormatSettings::DateTimeOverflowBehavior)0>::execute(std::vector> const&, std::shared_ptr const&, unsigned long, DB::detail::BehaviourOnErrorFromString, void*) @ 0x0000000012fecd1e 6. /build/src/Functions/FunctionsConversion.h:2472: 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&&) @ 0x0000000012f9cc64 7. /build/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 @ 0x0000000012fb122e 8. /build/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 @ 0x0000000012fb0a5a 9. /build/src/Functions/IFunctionAdaptors.cpp:10: DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000012d995fa 10. /build/src/Functions/IFunction.cpp:353: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d93b52 11. /build/src/Functions/IFunction.cpp:420: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d95059 12. /build/src/Functions/IFunction.cpp:498: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d95c72 13. /build/src/Functions/IFunction.cpp:513: DB::IFunctionBase::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d96059 14. /build/src/Functions/FunctionsConversion.h:3487: COW::immutable_ptr std::__function::__policy_invoker::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)>::__call_impl[abi:se190107], 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) @ 0x0000000012e00996 15. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000012ddcb1b 16. /build/src/Functions/IFunction.h:57: DB::IExecutableFunction::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000a08134a 17. /build/src/Functions/IFunction.cpp:351: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d93b02 18. /build/src/Functions/IFunction.cpp:177: DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d93698 19. /build/src/Functions/IFunction.cpp:343: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d93aad 20. /build/src/Functions/IFunction.cpp:424: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d94e1b 21. /build/src/Functions/IFunction.cpp:498: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d95c72 22. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3567: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000014034494 23. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3838: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000014019a9e 24. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3980: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000014018e31 25. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:4304: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000014042fa7 26. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5605: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000014013749 27. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000140127f9 28. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000014011fce 29. /build/src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000001406ce8a 30. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000014973b42 31. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000001497268d 2025.07.28 11:54:10.270609 [ 5747 ] {e707dd2d-cb79-485c-9030-b6784698f45f} executeQuery: Code: 1. DB::Exception: Resolved identifier 'item_id' in parent scope to expression 'l.item_id' with correlated column 'item_id'. In scope SELECT item_id FROM t1. (UNSUPPORTED_METHOD) (version 25.3.6.10636.altinitytest (altinity build)) (from [::1]:36076) (comment: 03255_parallel_replicas_join_algo_and_analyzer_4.sh) (query 5, line 7) (in query: --SELECT '----- enable_parallel_replicas=1 prefer_local_plan=0 parallel_replicas_prefer_local_join=1 -----'; SELECT sum(item_id) FROM ( SELECT item_id FROM t GROUP BY item_id ) AS l LEFT JOIN ( SELECT item_id FROM t1 ) AS r ON l.item_id = r.item_id ;), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/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 const&, String&&) @ 0x000000001404a1eb 4. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:1382: DB::QueryAnalyzer::tryResolveIdentifierInParentScopes(DB::IdentifierLookup const&, DB::IdentifierResolveScope&, DB::IdentifierResolveContext) @ 0x000000001402a8cc 5. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:1544: DB::QueryAnalyzer::tryResolveIdentifier(DB::IdentifierLookup const&, DB::IdentifierResolveScope&, DB::IdentifierResolveContext) @ 0x00000000140298dd 6. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3692: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000001401a2b4 7. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3980: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000014018e31 8. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:4304: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000014042fa7 9. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5605: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000014013749 10. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3870: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x00000000140199de 11. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5334: DB::QueryAnalyzer::resolveQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&) @ 0x00000000140454b0 12. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5142: DB::QueryAnalyzer::resolveJoin(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&) @ 0x0000000014046de9 13. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5361: DB::QueryAnalyzer::resolveQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&) @ 0x00000000140452d6 14. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5597: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000140136f0 15. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000140127f9 16. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000014011fce 17. /build/src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000001406ce8a 18. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000014973b42 19. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000001497268d 20. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000014974d24 21. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001492924b 22. /build/src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88641 23. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 24. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 25. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 26. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 27. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 28. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 29. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 30. ? @ 0x00007fbc6213eac3 31. ? @ 0x00007fbc621d0850 2025.07.28 11:54:10.290858 [ 5747 ] {} TCPHandler: Code: 1. DB::Exception: Resolved identifier 'item_id' in parent scope to expression 'l.item_id' with correlated column 'item_id'. In scope SELECT item_id FROM t1. (UNSUPPORTED_METHOD), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/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 const&, String&&) @ 0x000000001404a1eb 4. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:1382: DB::QueryAnalyzer::tryResolveIdentifierInParentScopes(DB::IdentifierLookup const&, DB::IdentifierResolveScope&, DB::IdentifierResolveContext) @ 0x000000001402a8cc 5. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:1544: DB::QueryAnalyzer::tryResolveIdentifier(DB::IdentifierLookup const&, DB::IdentifierResolveScope&, DB::IdentifierResolveContext) @ 0x00000000140298dd 6. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3692: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000001401a2b4 7. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3980: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000014018e31 8. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:4304: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000014042fa7 9. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5605: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000014013749 10. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3870: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x00000000140199de 11. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5334: DB::QueryAnalyzer::resolveQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&) @ 0x00000000140454b0 12. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5142: DB::QueryAnalyzer::resolveJoin(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&) @ 0x0000000014046de9 13. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5361: DB::QueryAnalyzer::resolveQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&) @ 0x00000000140452d6 14. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5597: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000140136f0 15. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000140127f9 16. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000014011fce 17. /build/src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000001406ce8a 18. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000014973b42 19. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000001497268d 20. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000014974d24 21. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001492924b 22. /build/src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88641 23. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 24. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 25. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 26. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 27. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 28. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 29. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 30. ? @ 0x00007fbc6213eac3 31. ? @ 0x00007fbc621d0850 2025.07.28 11:54:10.453821 [ 3969 ] {} test_13.rmt2 (7f9b740d-015c-470e-8cc6-8ba33be0dc63): auto DB::StorageReplicatedMergeTree::processQueueEntry(ReplicatedMergeTreeQueue::SelectedEntryPtr)::(anonymous class)::operator()(LogEntryPtr &) const: Code: 86. DB::HTTPException: Received error from remote server http://146b4357c08d:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Ftest%2F01165%2Ftest_13%2Frmt%2Freplicas%2F1&part=20250728_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.6.10636.altinitytest (altinity build)) '. (RECEIVED_ERROR_FROM_REMOTE_IO_SERVER), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.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 const&, int&&, String const&, unsigned long&&, String const&) @ 0x000000000feda8d9 4. /build/src/IO/HTTPCommon.cpp:104: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x000000000feda6e2 5. /build/src/IO/HTTPCommon.cpp:93: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x000000000feda537 6. /build/src/IO/ReadWriteBufferFromHTTP.cpp:277: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x000000001184a4c4 7. /build/src/IO/ReadWriteBufferFromHTTP.cpp:285: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x000000001184a615 8. /build/src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x000000001184ae59 9. /build/src/IO/ReadWriteBufferFromHTTP.cpp:472: void std::__function::__policy_invoker::__call_impl[abi:se190107]>(std::__function::__policy_storage const*) @ 0x000000001184cedd 10. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001184858b 11. /build/src/IO/ReadWriteBufferFromHTTP.cpp:465: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x000000001184bf0b 12. /build/src/IO/ReadBuffer.h:60: DB::ReadBuffer::next() @ 0x000000000a148c7b 13. /build/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) @ 0x0000000011849fb2 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]>&)>&, 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&) @ 0x0000000011841980 15. /build/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) @ 0x000000001621208e 16. /build/src/Storages/StorageReplicatedMergeTree.cpp:5228: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl[abi:se190107] const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000015f9a5fe 17. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000015ed8bfd 18. /build/src/Storages/StorageReplicatedMergeTree.cpp:2514: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x0000000015ec9aab 19. /build/src/Storages/StorageReplicatedMergeTree.cpp:2349: DB::StorageReplicatedMergeTree::executeLogEntry(DB::ReplicatedMergeTreeLogEntry&) @ 0x0000000015eba91b 20. /build/src/Storages/StorageReplicatedMergeTree.cpp:3876: bool std::__function::__policy_invoker&)>::__call_impl[abi:se190107])::$_1, bool (std::shared_ptr&)>>(std::__function::__policy_storage const*, std::shared_ptr&) @ 0x0000000015f9837e 21. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000165d6fc3 22. /build/src/Storages/StorageReplicatedMergeTree.cpp:3872: DB::StorageReplicatedMergeTree::processQueueEntry(std::shared_ptr) @ 0x0000000015efc18a 23. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001624c1b2 24. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000162f9c70 25. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x00000000162fa55a 26. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc6653 27. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000000fccc4c3 28. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc3d92 29. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fcca080 30. ? @ 0x00007fbc6213eac3 31. ? @ 0x00007fbc621d0850 (version 25.3.6.10636.altinitytest (altinity build)) 2025.07.28 11:54:10.608798 [ 3283 ] {} 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. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x000000000c25bc4b 4. /build/src/Access/SettingsConstraints.cpp:343: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000138596e3 5. /build/src/Access/SettingsConstraints.cpp:300: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000013858faf 6. /build/src/Access/SettingsConstraints.cpp:209: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x00000000138592b8 7. /build/src/Interpreters/Context.cpp:2690: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000014436134 8. /build/src/Interpreters/Context.cpp:2729: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x000000001443662b 9. /build/src/Server/TCPHandler.cpp:2158: DB::TCPHandler::processQuery(std::optional&) @ 0x00000000168f61df 10. /build/src/Server/TCPHandler.cpp:918: DB::TCPHandler::receivePacketsExpectQuery(std::optional&) @ 0x00000000168ef965 11. /build/src/Server/TCPHandler.cpp:491: DB::TCPHandler::runImpl() @ 0x00000000168e5eb4 12. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 13. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 14. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 16. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 17. ? @ 0x00007fbc6213eac3 18. ? @ 0x00007fbc621d0850 2025.07.28 11:54:10.616156 [ 3283 ] {} 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. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000000a074fcb 4. /build/src/Server/TCPHandler.cpp:897: DB::TCPHandler::receivePacketsExpectQuery(std::optional&) @ 0x00000000168efa89 5. /build/src/Server/TCPHandler.cpp:491: DB::TCPHandler::runImpl() @ 0x00000000168e5eb4 6. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 7. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 8. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 9. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 10. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 11. ? @ 0x00007fbc6213eac3 12. ? @ 0x00007fbc621d0850 2025.07.28 11:54:10.620993 [ 5825 ] {a07f5a80-6a86-4ac1-9cab-fde1ede59e2d} executeQuery: Code: 1. DB::Exception: Resolved identifier 'item_id' in parent scope to expression 'l.item_id' with correlated column 'item_id'. In scope SELECT item_id FROM t1 GROUP BY item_id. (UNSUPPORTED_METHOD) (version 25.3.6.10636.altinitytest (altinity build)) (from [::1]:36144) (comment: 03255_parallel_replicas_join_algo_and_analyzer_4.sh) (query 5, line 7) (in query: --SELECT '----- enable_parallel_replicas=0 prefer_local_plan=0 parallel_replicas_prefer_local_join=1 -----'; SELECT sum(item_id) FROM ( SELECT item_id FROM t ) AS l LEFT JOIN ( SELECT item_id FROM t1 GROUP BY item_id ) AS r ON l.item_id = r.item_id ;), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/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 const&, String&&) @ 0x000000001404a1eb 4. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:1382: DB::QueryAnalyzer::tryResolveIdentifierInParentScopes(DB::IdentifierLookup const&, DB::IdentifierResolveScope&, DB::IdentifierResolveContext) @ 0x000000001402a8cc 5. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:1544: DB::QueryAnalyzer::tryResolveIdentifier(DB::IdentifierLookup const&, DB::IdentifierResolveScope&, DB::IdentifierResolveContext) @ 0x00000000140298dd 6. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3692: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000001401a2b4 7. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3980: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000014018e31 8. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:4304: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000014042fa7 9. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5605: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000014013749 10. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3870: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x00000000140199de 11. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5334: DB::QueryAnalyzer::resolveQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&) @ 0x00000000140454b0 12. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5142: DB::QueryAnalyzer::resolveJoin(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&) @ 0x0000000014046de9 13. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5361: DB::QueryAnalyzer::resolveQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&) @ 0x00000000140452d6 14. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5597: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000140136f0 15. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000140127f9 16. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000014011fce 17. /build/src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000001406ce8a 18. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000014973b42 19. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000001497268d 20. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000014974d24 21. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001492924b 22. /build/src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88641 23. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 24. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 25. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 26. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 27. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 28. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 29. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 30. ? @ 0x00007fbc6213eac3 31. ? @ 0x00007fbc621d0850 2025.07.28 11:54:10.669811 [ 5825 ] {} TCPHandler: Code: 1. DB::Exception: Resolved identifier 'item_id' in parent scope to expression 'l.item_id' with correlated column 'item_id'. In scope SELECT item_id FROM t1 GROUP BY item_id. (UNSUPPORTED_METHOD), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/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 const&, String&&) @ 0x000000001404a1eb 4. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:1382: DB::QueryAnalyzer::tryResolveIdentifierInParentScopes(DB::IdentifierLookup const&, DB::IdentifierResolveScope&, DB::IdentifierResolveContext) @ 0x000000001402a8cc 5. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:1544: DB::QueryAnalyzer::tryResolveIdentifier(DB::IdentifierLookup const&, DB::IdentifierResolveScope&, DB::IdentifierResolveContext) @ 0x00000000140298dd 6. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3692: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000001401a2b4 7. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3980: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000014018e31 8. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:4304: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000014042fa7 9. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5605: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000014013749 10. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3870: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x00000000140199de 11. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5334: DB::QueryAnalyzer::resolveQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&) @ 0x00000000140454b0 12. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5142: DB::QueryAnalyzer::resolveJoin(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&) @ 0x0000000014046de9 13. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5361: DB::QueryAnalyzer::resolveQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&) @ 0x00000000140452d6 14. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5597: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000140136f0 15. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000140127f9 16. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000014011fce 17. /build/src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000001406ce8a 18. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000014973b42 19. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000001497268d 20. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000014974d24 21. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001492924b 22. /build/src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88641 23. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 24. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 25. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 26. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 27. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 28. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 29. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 30. ? @ 0x00007fbc6213eac3 31. ? @ 0x00007fbc621d0850 2025.07.28 11:54:10.749640 [ 17321 ] {d9b73e0d-318b-459e-91ea-3cd70fe648cf} 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.6.10636.altinitytest (altinity build)) (from [::1]:36084) (comment: 00910_decimal_group_array_crash_3783.sql) (query 2, line 2) (in query: select groupArray(s) from (select sum(n) s from (select toDecimal64(1, 5) as n));), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.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&&) @ 0x000000000fc1a9d9 4. /build/src/Common/MemoryTracker.cpp:298: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000000fc19854 5. /build/src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000000fc19293 6. /build/src/Interpreters/Aggregator.cpp:1835: DB::Aggregator::checkLimits(unsigned long, bool&) const @ 0x0000000014589d8c 7. /build/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 @ 0x0000000014593bec 8. /build/src/Processors/Transforms/AggregatingTransform.cpp:690: DB::AggregatingTransform::consume(DB::Chunk) @ 0x0000000016bf205c 9. /build/src/Processors/Transforms/AggregatingTransform.cpp:648: DB::AggregatingTransform::work() @ 0x0000000016bef6c6 10. /build/src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x00000000169bd00f 11. /build/src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x00000000169b2105 12. /build/src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeSingleThread(unsigned long) @ 0x00000000169b23be 13. /build/src/Processors/Executors/PipelineExecutor.cpp:416: void std::__function::__policy_invoker::__call_impl[abi:se190107]>(std::__function::__policy_storage const*) @ 0x00000000169b2e3f 14. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc6653 15. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000000fccc4c3 16. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc3d92 17. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fcca080 18. ? @ 0x00007fbc6213eac3 19. ? @ 0x00007fbc621d0850 2025.07.28 11:54:10.768811 [ 17321 ] {} 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. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.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&&) @ 0x000000000fc1a9d9 4. /build/src/Common/MemoryTracker.cpp:298: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000000fc19854 5. /build/src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000000fc19293 6. /build/src/Interpreters/Aggregator.cpp:1835: DB::Aggregator::checkLimits(unsigned long, bool&) const @ 0x0000000014589d8c 7. /build/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 @ 0x0000000014593bec 8. /build/src/Processors/Transforms/AggregatingTransform.cpp:690: DB::AggregatingTransform::consume(DB::Chunk) @ 0x0000000016bf205c 9. /build/src/Processors/Transforms/AggregatingTransform.cpp:648: DB::AggregatingTransform::work() @ 0x0000000016bef6c6 10. /build/src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x00000000169bd00f 11. /build/src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x00000000169b2105 12. /build/src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeSingleThread(unsigned long) @ 0x00000000169b23be 13. /build/src/Processors/Executors/PipelineExecutor.cpp:416: void std::__function::__policy_invoker::__call_impl[abi:se190107]>(std::__function::__policy_storage const*) @ 0x00000000169b2e3f 14. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc6653 15. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000000fccc4c3 16. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc3d92 17. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fcca080 18. ? @ 0x00007fbc6213eac3 19. ? @ 0x00007fbc621d0850 Job's origin stack trace: 0. /build/src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000000fc33b84 1. /build/src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000000fcc2ea7 2. /build/src/Common/ThreadPool.cpp:401: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fcc7f1c 3. /build/src/Common/ThreadPool.cpp:494: ThreadPoolImpl>::scheduleOrThrowOnError(std::function, Priority) @ 0x000000000fcc7a0e 4. /build/src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::spawnThreadsImpl() @ 0x00000000169b2c0c 5. /build/src/Processors/Executors/PipelineExecutor.cpp:394: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x00000000169b0ba7 6. /build/src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x00000000169b03f4 7. /build/src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:se190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169bfeab 8. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc3d92 9. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fcca080 10. ? @ 0x00007fbc6213eac3 11. ? @ 0x00007fbc621d0850 Job's origin stack trace: 0. /build/src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000000fc33b84 1. /build/src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000000fcc2ea7 2. /build/src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fcc535c 3. /build/src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000000fcc584d 4. /build/src/Common/ThreadPool.h:279: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x00000000169bf193 5. /build/src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x00000000169bf518 6. /build/src/Server/TCPHandler.cpp:1237: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x00000000168f1525 7. /build/src/Server/TCPHandler.cpp:678: DB::TCPHandler::runImpl() @ 0x00000000168e68e5 8. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 9. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 10. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 11. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 12. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 13. ? @ 0x00007fbc6213eac3 14. ? @ 0x00007fbc621d0850 2025.07.28 11:54:11.015605 [ 3283 ] {f29a125d-c242-4f08-9944-8ad11eea9fa7} executeQuery: Code: 1. DB::Exception: Resolved identifier 'item_id' in parent scope to expression 'l.item_id' with correlated column 'item_id'. In scope SELECT item_id FROM t1 GROUP BY item_id. (UNSUPPORTED_METHOD) (version 25.3.6.10636.altinitytest (altinity build)) (from [::1]:36156) (comment: 03255_parallel_replicas_join_algo_and_analyzer_4.sh) (query 5, line 7) (in query: --SELECT '----- enable_parallel_replicas=1 prefer_local_plan=0 parallel_replicas_prefer_local_join=1 -----'; SELECT sum(item_id) FROM ( SELECT item_id FROM t ) AS l LEFT JOIN ( SELECT item_id FROM t1 GROUP BY item_id ) AS r ON l.item_id = r.item_id ;), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/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 const&, String&&) @ 0x000000001404a1eb 4. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:1382: DB::QueryAnalyzer::tryResolveIdentifierInParentScopes(DB::IdentifierLookup const&, DB::IdentifierResolveScope&, DB::IdentifierResolveContext) @ 0x000000001402a8cc 5. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:1544: DB::QueryAnalyzer::tryResolveIdentifier(DB::IdentifierLookup const&, DB::IdentifierResolveScope&, DB::IdentifierResolveContext) @ 0x00000000140298dd 6. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3692: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000001401a2b4 7. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3980: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000014018e31 8. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:4304: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000014042fa7 9. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5605: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000014013749 10. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3870: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x00000000140199de 11. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5334: DB::QueryAnalyzer::resolveQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&) @ 0x00000000140454b0 12. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5142: DB::QueryAnalyzer::resolveJoin(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&) @ 0x0000000014046de9 13. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5361: DB::QueryAnalyzer::resolveQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&) @ 0x00000000140452d6 14. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5597: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000140136f0 15. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000140127f9 16. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000014011fce 17. /build/src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000001406ce8a 18. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000014973b42 19. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000001497268d 20. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000014974d24 21. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001492924b 22. /build/src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88641 23. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 24. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 25. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 26. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 27. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 28. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 29. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 30. ? @ 0x00007fbc6213eac3 31. ? @ 0x00007fbc621d0850 2025.07.28 11:54:11.064128 [ 3283 ] {} TCPHandler: Code: 1. DB::Exception: Resolved identifier 'item_id' in parent scope to expression 'l.item_id' with correlated column 'item_id'. In scope SELECT item_id FROM t1 GROUP BY item_id. (UNSUPPORTED_METHOD), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/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 const&, String&&) @ 0x000000001404a1eb 4. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:1382: DB::QueryAnalyzer::tryResolveIdentifierInParentScopes(DB::IdentifierLookup const&, DB::IdentifierResolveScope&, DB::IdentifierResolveContext) @ 0x000000001402a8cc 5. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:1544: DB::QueryAnalyzer::tryResolveIdentifier(DB::IdentifierLookup const&, DB::IdentifierResolveScope&, DB::IdentifierResolveContext) @ 0x00000000140298dd 6. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3692: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000001401a2b4 7. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3980: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000014018e31 8. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:4304: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000014042fa7 9. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5605: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000014013749 10. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3870: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x00000000140199de 11. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5334: DB::QueryAnalyzer::resolveQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&) @ 0x00000000140454b0 12. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5142: DB::QueryAnalyzer::resolveJoin(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&) @ 0x0000000014046de9 13. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5361: DB::QueryAnalyzer::resolveQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&) @ 0x00000000140452d6 14. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5597: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000140136f0 15. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000140127f9 16. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000014011fce 17. /build/src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000001406ce8a 18. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000014973b42 19. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000001497268d 20. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000014974d24 21. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001492924b 22. /build/src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88641 23. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 24. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 25. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 26. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 27. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 28. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 29. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 30. ? @ 0x00007fbc6213eac3 31. ? @ 0x00007fbc621d0850 2025.07.28 11:54:11.361494 [ 17321 ] {2fa1a08b-75b6-4791-a893-5c2acb7623e0} executeQuery: Code: 1. DB::Exception: Resolved identifier 'item_id' in parent scope to expression 'l.item_id' with correlated column 'item_id'. In scope SELECT item_id FROM t1. (UNSUPPORTED_METHOD) (version 25.3.6.10636.altinitytest (altinity build)) (from [::1]:45500) (comment: 03255_parallel_replicas_join_algo_and_analyzer_4.sh) (query 5, line 7) (in query: --SELECT '----- enable_parallel_replicas=0 prefer_local_plan=0 parallel_replicas_prefer_local_join=1 -----'; SELECT sum(item_id) FROM ( SELECT item_id, price_sold FROM t ) AS l LEFT JOIN ( SELECT item_id FROM t1 ) AS r ON l.item_id = r.item_id GROUP BY price_sold ORDER BY price_sold ;), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/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 const&, String&&) @ 0x000000001404a1eb 4. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:1382: DB::QueryAnalyzer::tryResolveIdentifierInParentScopes(DB::IdentifierLookup const&, DB::IdentifierResolveScope&, DB::IdentifierResolveContext) @ 0x000000001402a8cc 5. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:1544: DB::QueryAnalyzer::tryResolveIdentifier(DB::IdentifierLookup const&, DB::IdentifierResolveScope&, DB::IdentifierResolveContext) @ 0x00000000140298dd 6. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3692: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000001401a2b4 7. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3980: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000014018e31 8. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:4304: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000014042fa7 9. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5605: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000014013749 10. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3870: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x00000000140199de 11. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5334: DB::QueryAnalyzer::resolveQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&) @ 0x00000000140454b0 12. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5142: DB::QueryAnalyzer::resolveJoin(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&) @ 0x0000000014046de9 13. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5361: DB::QueryAnalyzer::resolveQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&) @ 0x00000000140452d6 14. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5597: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000140136f0 15. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000140127f9 16. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000014011fce 17. /build/src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000001406ce8a 18. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000014973b42 19. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000001497268d 20. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000014974d24 21. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001492924b 22. /build/src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88641 23. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 24. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 25. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 26. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 27. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 28. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 29. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 30. ? @ 0x00007fbc6213eac3 31. ? @ 0x00007fbc621d0850 2025.07.28 11:54:11.395327 [ 17321 ] {} TCPHandler: Code: 1. DB::Exception: Resolved identifier 'item_id' in parent scope to expression 'l.item_id' with correlated column 'item_id'. In scope SELECT item_id FROM t1. (UNSUPPORTED_METHOD), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/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 const&, String&&) @ 0x000000001404a1eb 4. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:1382: DB::QueryAnalyzer::tryResolveIdentifierInParentScopes(DB::IdentifierLookup const&, DB::IdentifierResolveScope&, DB::IdentifierResolveContext) @ 0x000000001402a8cc 5. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:1544: DB::QueryAnalyzer::tryResolveIdentifier(DB::IdentifierLookup const&, DB::IdentifierResolveScope&, DB::IdentifierResolveContext) @ 0x00000000140298dd 6. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3692: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000001401a2b4 7. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3980: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000014018e31 8. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:4304: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000014042fa7 9. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5605: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000014013749 10. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3870: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x00000000140199de 11. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5334: DB::QueryAnalyzer::resolveQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&) @ 0x00000000140454b0 12. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5142: DB::QueryAnalyzer::resolveJoin(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&) @ 0x0000000014046de9 13. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5361: DB::QueryAnalyzer::resolveQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&) @ 0x00000000140452d6 14. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5597: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000140136f0 15. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000140127f9 16. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000014011fce 17. /build/src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000001406ce8a 18. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000014973b42 19. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000001497268d 20. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000014974d24 21. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001492924b 22. /build/src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88641 23. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 24. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 25. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 26. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 27. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 28. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 29. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 30. ? @ 0x00007fbc6213eac3 31. ? @ 0x00007fbc621d0850 2025.07.28 11:54:11.398014 [ 3966 ] {} test_13.rmt2 (7f9b740d-015c-470e-8cc6-8ba33be0dc63): auto DB::StorageReplicatedMergeTree::processQueueEntry(ReplicatedMergeTreeQueue::SelectedEntryPtr)::(anonymous class)::operator()(LogEntryPtr &) const: Code: 86. DB::HTTPException: Received error from remote server http://146b4357c08d:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Ftest%2F01165%2Ftest_13%2Frmt%2Freplicas%2F1&part=20250728_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.6.10636.altinitytest (altinity build)) '. (RECEIVED_ERROR_FROM_REMOTE_IO_SERVER), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.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 const&, int&&, String const&, unsigned long&&, String const&) @ 0x000000000feda8d9 4. /build/src/IO/HTTPCommon.cpp:104: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x000000000feda6e2 5. /build/src/IO/HTTPCommon.cpp:93: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x000000000feda537 6. /build/src/IO/ReadWriteBufferFromHTTP.cpp:277: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x000000001184a4c4 7. /build/src/IO/ReadWriteBufferFromHTTP.cpp:285: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x000000001184a615 8. /build/src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x000000001184ae59 9. /build/src/IO/ReadWriteBufferFromHTTP.cpp:472: void std::__function::__policy_invoker::__call_impl[abi:se190107]>(std::__function::__policy_storage const*) @ 0x000000001184cedd 10. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001184858b 11. /build/src/IO/ReadWriteBufferFromHTTP.cpp:465: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x000000001184bf0b 12. /build/src/IO/ReadBuffer.h:60: DB::ReadBuffer::next() @ 0x000000000a148c7b 13. /build/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) @ 0x0000000011849fb2 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]>&)>&, 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&) @ 0x0000000011841980 15. /build/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) @ 0x000000001621208e 16. /build/src/Storages/StorageReplicatedMergeTree.cpp:5228: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl[abi:se190107] const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000015f9a5fe 17. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000015ed8bfd 18. /build/src/Storages/StorageReplicatedMergeTree.cpp:2514: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x0000000015ec9aab 19. /build/src/Storages/StorageReplicatedMergeTree.cpp:2349: DB::StorageReplicatedMergeTree::executeLogEntry(DB::ReplicatedMergeTreeLogEntry&) @ 0x0000000015eba91b 20. /build/src/Storages/StorageReplicatedMergeTree.cpp:3876: bool std::__function::__policy_invoker&)>::__call_impl[abi:se190107])::$_1, bool (std::shared_ptr&)>>(std::__function::__policy_storage const*, std::shared_ptr&) @ 0x0000000015f9837e 21. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000165d6fc3 22. /build/src/Storages/StorageReplicatedMergeTree.cpp:3872: DB::StorageReplicatedMergeTree::processQueueEntry(std::shared_ptr) @ 0x0000000015efc18a 23. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001624c1b2 24. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000162f9c70 25. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x00000000162fa55a 26. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc6653 27. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000000fccc4c3 28. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc3d92 29. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fcca080 30. ? @ 0x00007fbc6213eac3 31. ? @ 0x00007fbc621d0850 (version 25.3.6.10636.altinitytest (altinity build)) 2025.07.28 11:54:11.574603 [ 3283 ] {e49eed4b-cb4b-4ed9-b761-764d707761f6} executeQuery: Code: 1. DB::Exception: Resolved identifier 'item_id' in parent scope to expression 'l.item_id' with correlated column 'item_id'. In scope SELECT item_id FROM t1. (UNSUPPORTED_METHOD) (version 25.3.6.10636.altinitytest (altinity build)) (from [::1]:45532) (comment: 03255_parallel_replicas_join_algo_and_analyzer_4.sh) (query 5, line 7) (in query: --SELECT '----- enable_parallel_replicas=1 prefer_local_plan=0 parallel_replicas_prefer_local_join=1 -----'; SELECT sum(item_id) FROM ( SELECT item_id, price_sold FROM t ) AS l LEFT JOIN ( SELECT item_id FROM t1 ) AS r ON l.item_id = r.item_id GROUP BY price_sold ORDER BY price_sold ;), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/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 const&, String&&) @ 0x000000001404a1eb 4. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:1382: DB::QueryAnalyzer::tryResolveIdentifierInParentScopes(DB::IdentifierLookup const&, DB::IdentifierResolveScope&, DB::IdentifierResolveContext) @ 0x000000001402a8cc 5. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:1544: DB::QueryAnalyzer::tryResolveIdentifier(DB::IdentifierLookup const&, DB::IdentifierResolveScope&, DB::IdentifierResolveContext) @ 0x00000000140298dd 6. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3692: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000001401a2b4 7. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3980: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000014018e31 8. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:4304: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000014042fa7 9. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5605: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000014013749 10. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3870: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x00000000140199de 11. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5334: DB::QueryAnalyzer::resolveQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&) @ 0x00000000140454b0 12. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5142: DB::QueryAnalyzer::resolveJoin(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&) @ 0x0000000014046de9 13. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5361: DB::QueryAnalyzer::resolveQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&) @ 0x00000000140452d6 14. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5597: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000140136f0 15. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000140127f9 16. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000014011fce 17. /build/src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000001406ce8a 18. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000014973b42 19. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000001497268d 20. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000014974d24 21. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001492924b 22. /build/src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88641 23. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 24. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 25. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 26. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 27. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 28. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 29. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 30. ? @ 0x00007fbc6213eac3 31. ? @ 0x00007fbc621d0850 2025.07.28 11:54:11.593080 [ 3283 ] {} TCPHandler: Code: 1. DB::Exception: Resolved identifier 'item_id' in parent scope to expression 'l.item_id' with correlated column 'item_id'. In scope SELECT item_id FROM t1. (UNSUPPORTED_METHOD), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/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 const&, String&&) @ 0x000000001404a1eb 4. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:1382: DB::QueryAnalyzer::tryResolveIdentifierInParentScopes(DB::IdentifierLookup const&, DB::IdentifierResolveScope&, DB::IdentifierResolveContext) @ 0x000000001402a8cc 5. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:1544: DB::QueryAnalyzer::tryResolveIdentifier(DB::IdentifierLookup const&, DB::IdentifierResolveScope&, DB::IdentifierResolveContext) @ 0x00000000140298dd 6. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3692: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000001401a2b4 7. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3980: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000014018e31 8. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:4304: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000014042fa7 9. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5605: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000014013749 10. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3870: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x00000000140199de 11. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5334: DB::QueryAnalyzer::resolveQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&) @ 0x00000000140454b0 12. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5142: DB::QueryAnalyzer::resolveJoin(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&) @ 0x0000000014046de9 13. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5361: DB::QueryAnalyzer::resolveQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&) @ 0x00000000140452d6 14. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5597: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000140136f0 15. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000140127f9 16. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000014011fce 17. /build/src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000001406ce8a 18. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000014973b42 19. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000001497268d 20. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000014974d24 21. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001492924b 22. /build/src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88641 23. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 24. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 25. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 26. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 27. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 28. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 29. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 30. ? @ 0x00007fbc6213eac3 31. ? @ 0x00007fbc621d0850 2025.07.28 11:54:11.788304 [ 3283 ] {d6971685-89e5-4787-921d-bf572dc39440} executeQuery: Code: 1. DB::Exception: Resolved identifier 'item_id' in parent scope to expression 'l.item_id' with correlated column 'item_id'. In scope SELECT item_id FROM t1. (UNSUPPORTED_METHOD) (version 25.3.6.10636.altinitytest (altinity build)) (from [::1]:45552) (comment: 03255_parallel_replicas_join_algo_and_analyzer_4.sh) (query 5, line 7) (in query: --SELECT '----- enable_parallel_replicas=0 prefer_local_plan=1 parallel_replicas_prefer_local_join=1 -----'; SELECT sum(item_id) FROM ( SELECT item_id FROM t GROUP BY item_id ) AS l LEFT JOIN ( SELECT item_id FROM t1 ) AS r ON l.item_id = r.item_id ;), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/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 const&, String&&) @ 0x000000001404a1eb 4. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:1382: DB::QueryAnalyzer::tryResolveIdentifierInParentScopes(DB::IdentifierLookup const&, DB::IdentifierResolveScope&, DB::IdentifierResolveContext) @ 0x000000001402a8cc 5. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:1544: DB::QueryAnalyzer::tryResolveIdentifier(DB::IdentifierLookup const&, DB::IdentifierResolveScope&, DB::IdentifierResolveContext) @ 0x00000000140298dd 6. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3692: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000001401a2b4 7. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3980: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000014018e31 8. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:4304: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000014042fa7 9. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5605: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000014013749 10. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3870: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x00000000140199de 11. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5334: DB::QueryAnalyzer::resolveQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&) @ 0x00000000140454b0 12. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5142: DB::QueryAnalyzer::resolveJoin(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&) @ 0x0000000014046de9 13. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5361: DB::QueryAnalyzer::resolveQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&) @ 0x00000000140452d6 14. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5597: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000140136f0 15. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000140127f9 16. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000014011fce 17. /build/src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000001406ce8a 18. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000014973b42 19. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000001497268d 20. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000014974d24 21. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001492924b 22. /build/src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88641 23. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 24. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 25. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 26. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 27. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 28. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 29. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 30. ? @ 0x00007fbc6213eac3 31. ? @ 0x00007fbc621d0850 2025.07.28 11:54:11.792000 [ 3283 ] {} TCPHandler: Code: 1. DB::Exception: Resolved identifier 'item_id' in parent scope to expression 'l.item_id' with correlated column 'item_id'. In scope SELECT item_id FROM t1. (UNSUPPORTED_METHOD), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/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 const&, String&&) @ 0x000000001404a1eb 4. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:1382: DB::QueryAnalyzer::tryResolveIdentifierInParentScopes(DB::IdentifierLookup const&, DB::IdentifierResolveScope&, DB::IdentifierResolveContext) @ 0x000000001402a8cc 5. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:1544: DB::QueryAnalyzer::tryResolveIdentifier(DB::IdentifierLookup const&, DB::IdentifierResolveScope&, DB::IdentifierResolveContext) @ 0x00000000140298dd 6. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3692: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000001401a2b4 7. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3980: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000014018e31 8. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:4304: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000014042fa7 9. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5605: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000014013749 10. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3870: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x00000000140199de 11. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5334: DB::QueryAnalyzer::resolveQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&) @ 0x00000000140454b0 12. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5142: DB::QueryAnalyzer::resolveJoin(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&) @ 0x0000000014046de9 13. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5361: DB::QueryAnalyzer::resolveQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&) @ 0x00000000140452d6 14. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5597: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000140136f0 15. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000140127f9 16. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000014011fce 17. /build/src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000001406ce8a 18. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000014973b42 19. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000001497268d 20. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000014974d24 21. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001492924b 22. /build/src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88641 23. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 24. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 25. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 26. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 27. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 28. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 29. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 30. ? @ 0x00007fbc6213eac3 31. ? @ 0x00007fbc621d0850 2025.07.28 11:54:11.851798 [ 17256 ] {d20c7740-1095-45eb-9ad4-f95ac8f484dd} executeQuery: Code: 153. DB::Exception: Division by zero: while executing 'FUNCTION modulo(1_UInt8 :: 1, modulo(plus(__table1.number, 500_UInt16), 1000_UInt16) :: 2) -> modulo(1_UInt8, modulo(plus(__table1.number, 500_UInt16), 1000_UInt16)) UInt16 : 3'. (ILLEGAL_DIVISION) (version 25.3.6.10636.altinitytest (altinity build)) (from [::1]:35846) (comment: 00093_union_race_conditions_4.sh) (query 1, line 1) (in query: SELECT 1 % ((number + 500) % 1000) FROM numbers_mt(1000);), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000000a074fcb 4. /build/src/Functions/DivisionUtils.h:26: void DB::impl_::BinaryOperation, unsigned short>::process<(DB::impl_::OpCase)1>(char8_t const*, unsigned short const*, unsigned short*, unsigned long, DB::PODArray, 63ul, 64ul> const*) @ 0x000000000d184621 5. /build/src/Functions/FunctionBinaryArithmetic.h:2338: COW::immutable_ptr DB::FunctionBinaryArithmetic::executeNumeric, DB::DataTypeNumber>(std::vector> const&, DB::DataTypeNumber const&, DB::DataTypeNumber const&, DB::PODArray, 63ul, 64ul> const*) const @ 0x000000000d3a6416 6. /build/src/Functions/FunctionBinaryArithmetic.h:2508: 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&&) @ 0x000000000d3a4a68 7. /build/src/Functions/FunctionBinaryArithmetic.h:846: 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&&) @ 0x000000000d3a3ec7 8. /build/src/Functions/FunctionBinaryArithmetic.h:844: DB::FunctionBinaryArithmetic::executeImpl2(std::vector> const&, std::shared_ptr const&, unsigned long, DB::PODArray, 63ul, 64ul> const*) const @ 0x000000000d3a03c5 9. /build/src/Functions/FunctionBinaryArithmetic.h:2410: DB::FunctionBinaryArithmetic::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000d39e94c 10. /build/src/Functions/FunctionBinaryArithmetic.h:2645: DB::FunctionBinaryArithmeticWithConstants::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000d39dbd4 11. /build/src/Functions/IFunctionAdaptors.cpp:10: DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000012d995fa 12. /build/src/Functions/IFunction.cpp:353: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d93b52 13. /build/src/Functions/IFunction.cpp:420: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d95059 14. /build/src/Functions/IFunction.cpp:498: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d95c72 15. /build/src/Interpreters/ExpressionActions.cpp:636: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x00000000145176f3 16. /build/src/Processors/Transforms/ExpressionTransform.cpp:25: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x0000000016c0b34c 17. /build/src/Processors/ISimpleTransform.h:33: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000011a9a453 18. /build/src/Processors/ISimpleTransform.cpp:89: DB::ISimpleTransform::work() @ 0x000000001699fca0 19. /build/src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x00000000169bd00f 20. /build/src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x00000000169b2105 21. /build/src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeSingleThread(unsigned long) @ 0x00000000169b23be 22. /build/src/Processors/Executors/PipelineExecutor.cpp:454: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x00000000169b0be7 23. /build/src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x00000000169b03f4 24. /build/src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:se190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169bfeab 25. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc3d92 26. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fcca080 27. ? @ 0x00007fbc6213eac3 28. ? @ 0x00007fbc621d0850 2025.07.28 11:54:11.882800 [ 17256 ] {} TCPHandler: Code: 153. DB::Exception: Division by zero: while executing 'FUNCTION modulo(1_UInt8 :: 1, modulo(plus(__table1.number, 500_UInt16), 1000_UInt16) :: 2) -> modulo(1_UInt8, modulo(plus(__table1.number, 500_UInt16), 1000_UInt16)) UInt16 : 3'. (ILLEGAL_DIVISION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000000a074fcb 4. /build/src/Functions/DivisionUtils.h:26: void DB::impl_::BinaryOperation, unsigned short>::process<(DB::impl_::OpCase)1>(char8_t const*, unsigned short const*, unsigned short*, unsigned long, DB::PODArray, 63ul, 64ul> const*) @ 0x000000000d184621 5. /build/src/Functions/FunctionBinaryArithmetic.h:2338: COW::immutable_ptr DB::FunctionBinaryArithmetic::executeNumeric, DB::DataTypeNumber>(std::vector> const&, DB::DataTypeNumber const&, DB::DataTypeNumber const&, DB::PODArray, 63ul, 64ul> const*) const @ 0x000000000d3a6416 6. /build/src/Functions/FunctionBinaryArithmetic.h:2508: 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&&) @ 0x000000000d3a4a68 7. /build/src/Functions/FunctionBinaryArithmetic.h:846: 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&&) @ 0x000000000d3a3ec7 8. /build/src/Functions/FunctionBinaryArithmetic.h:844: DB::FunctionBinaryArithmetic::executeImpl2(std::vector> const&, std::shared_ptr const&, unsigned long, DB::PODArray, 63ul, 64ul> const*) const @ 0x000000000d3a03c5 9. /build/src/Functions/FunctionBinaryArithmetic.h:2410: DB::FunctionBinaryArithmetic::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000d39e94c 10. /build/src/Functions/FunctionBinaryArithmetic.h:2645: DB::FunctionBinaryArithmeticWithConstants::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000d39dbd4 11. /build/src/Functions/IFunctionAdaptors.cpp:10: DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000012d995fa 12. /build/src/Functions/IFunction.cpp:353: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d93b52 13. /build/src/Functions/IFunction.cpp:420: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d95059 14. /build/src/Functions/IFunction.cpp:498: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d95c72 15. /build/src/Interpreters/ExpressionActions.cpp:636: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x00000000145176f3 16. /build/src/Processors/Transforms/ExpressionTransform.cpp:25: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x0000000016c0b34c 17. /build/src/Processors/ISimpleTransform.h:33: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000011a9a453 18. /build/src/Processors/ISimpleTransform.cpp:89: DB::ISimpleTransform::work() @ 0x000000001699fca0 19. /build/src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x00000000169bd00f 20. /build/src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x00000000169b2105 21. /build/src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeSingleThread(unsigned long) @ 0x00000000169b23be 22. /build/src/Processors/Executors/PipelineExecutor.cpp:454: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x00000000169b0be7 23. /build/src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x00000000169b03f4 24. /build/src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:se190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169bfeab 25. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc3d92 26. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fcca080 27. ? @ 0x00007fbc6213eac3 28. ? @ 0x00007fbc621d0850 Job's origin stack trace: 0. /build/src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000000fc33b84 1. /build/src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000000fcc2ea7 2. /build/src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fcc535c 3. /build/src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000000fcc584d 4. /build/src/Common/ThreadPool.h:279: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x00000000169bf193 5. /build/src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x00000000169bf518 6. /build/src/Server/TCPHandler.cpp:1237: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x00000000168f1525 7. /build/src/Server/TCPHandler.cpp:678: DB::TCPHandler::runImpl() @ 0x00000000168e68e5 8. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 9. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 10. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 11. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 12. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 13. ? @ 0x00007fbc6213eac3 14. ? @ 0x00007fbc621d0850 2025.07.28 11:54:12.045594 [ 3285 ] {d70b5169-ba4c-47d2-905b-ed108a20656a} executeQuery: Code: 47. DB::Exception: Unknown expression or function identifier `x` in scope x = 1. (UNKNOWN_IDENTIFIER) (version 25.3.6.10636.altinitytest (altinity build)) (from [::1]:45518) (comment: 00853_join_with_nulls_crash.sql) (query 7, line 19) (in query: SELECT s1.other, s2.other, count_a, count_b, toTypeName(s1.other), toTypeName(s2.other) FROM ( SELECT other, count() AS count_a FROM table_a GROUP BY other ) s1 ALL FULL JOIN ( SELECT other, count() AS count_b FROM table_b GROUP BY other ) s2 ON s1.other = s2.other ORDER BY s2.other DESC, count_a, s1.other;), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.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&&) @ 0x000000001404b3b9 4. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3771: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000001401b849 5. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3980: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000014018e31 6. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:2925: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000001402fcbd 7. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3838: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000014019a9e 8. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:209: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000001401270e 9. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000014011fce 10. /build/src/Planner/Utils.cpp:458: DB::buildFilterInfo(std::shared_ptr, std::shared_ptr const&, std::shared_ptr&, std::unordered_set, std::equal_to, std::allocator>) @ 0x0000000013fe8bcf 11. /build/src/Planner/PlannerJoinTree.cpp:535: DB::(anonymous namespace)::buildQueryPlanForTableExpression(std::shared_ptr, std::shared_ptr const&, DB::SelectQueryInfo const&, DB::SelectQueryOptions const&, std::shared_ptr&, bool, bool) @ 0x00000000149956d3 12. /build/src/Planner/PlannerJoinTree.cpp:2252: DB::buildJoinTreeQueryPlan(std::shared_ptr const&, DB::SelectQueryInfo const&, DB::SelectQueryOptions&, std::unordered_set, std::equal_to, std::allocator> const&, std::shared_ptr&) @ 0x000000001498e109 13. /build/src/Planner/Planner.cpp:1553: DB::Planner::buildPlanForQueryNode() @ 0x0000000014979dae 14. /build/src/Planner/Planner.cpp:1308: DB::Planner::buildQueryPlanIfNeeded() @ 0x000000001497685c 15. /build/src/Planner/PlannerJoinTree.cpp:1202: DB::(anonymous namespace)::buildQueryPlanForTableExpression(std::shared_ptr, std::shared_ptr const&, DB::SelectQueryInfo const&, DB::SelectQueryOptions const&, std::shared_ptr&, bool, bool) @ 0x0000000014994644 16. /build/src/Planner/PlannerJoinTree.cpp:2252: DB::buildJoinTreeQueryPlan(std::shared_ptr const&, DB::SelectQueryInfo const&, DB::SelectQueryOptions&, std::unordered_set, std::equal_to, std::allocator> const&, std::shared_ptr&) @ 0x000000001498e109 17. /build/src/Planner/Planner.cpp:1553: DB::Planner::buildPlanForQueryNode() @ 0x0000000014979dae 18. /build/src/Planner/Planner.cpp:1308: DB::Planner::buildQueryPlanIfNeeded() @ 0x000000001497685c 19. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:255: DB::InterpreterSelectQueryAnalyzer::getQueryPlan() @ 0x000000001497476d 20. /build/src/Interpreters/executeQuery.cpp:1405: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88806 21. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 22. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 23. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 24. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 25. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 26. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 27. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 28. ? @ 0x00007fbc6213eac3 29. ? @ 0x00007fbc621d0850 2025.07.28 11:54:12.067208 [ 3285 ] {} TCPHandler: Code: 47. DB::Exception: Unknown expression or function identifier `x` in scope x = 1. (UNKNOWN_IDENTIFIER), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.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&&) @ 0x000000001404b3b9 4. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3771: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000001401b849 5. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3980: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000014018e31 6. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:2925: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000001402fcbd 7. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3838: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000014019a9e 8. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:209: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000001401270e 9. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000014011fce 10. /build/src/Planner/Utils.cpp:458: DB::buildFilterInfo(std::shared_ptr, std::shared_ptr const&, std::shared_ptr&, std::unordered_set, std::equal_to, std::allocator>) @ 0x0000000013fe8bcf 11. /build/src/Planner/PlannerJoinTree.cpp:535: DB::(anonymous namespace)::buildQueryPlanForTableExpression(std::shared_ptr, std::shared_ptr const&, DB::SelectQueryInfo const&, DB::SelectQueryOptions const&, std::shared_ptr&, bool, bool) @ 0x00000000149956d3 12. /build/src/Planner/PlannerJoinTree.cpp:2252: DB::buildJoinTreeQueryPlan(std::shared_ptr const&, DB::SelectQueryInfo const&, DB::SelectQueryOptions&, std::unordered_set, std::equal_to, std::allocator> const&, std::shared_ptr&) @ 0x000000001498e109 13. /build/src/Planner/Planner.cpp:1553: DB::Planner::buildPlanForQueryNode() @ 0x0000000014979dae 14. /build/src/Planner/Planner.cpp:1308: DB::Planner::buildQueryPlanIfNeeded() @ 0x000000001497685c 15. /build/src/Planner/PlannerJoinTree.cpp:1202: DB::(anonymous namespace)::buildQueryPlanForTableExpression(std::shared_ptr, std::shared_ptr const&, DB::SelectQueryInfo const&, DB::SelectQueryOptions const&, std::shared_ptr&, bool, bool) @ 0x0000000014994644 16. /build/src/Planner/PlannerJoinTree.cpp:2252: DB::buildJoinTreeQueryPlan(std::shared_ptr const&, DB::SelectQueryInfo const&, DB::SelectQueryOptions&, std::unordered_set, std::equal_to, std::allocator> const&, std::shared_ptr&) @ 0x000000001498e109 17. /build/src/Planner/Planner.cpp:1553: DB::Planner::buildPlanForQueryNode() @ 0x0000000014979dae 18. /build/src/Planner/Planner.cpp:1308: DB::Planner::buildQueryPlanIfNeeded() @ 0x000000001497685c 19. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:255: DB::InterpreterSelectQueryAnalyzer::getQueryPlan() @ 0x000000001497476d 20. /build/src/Interpreters/executeQuery.cpp:1405: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88806 21. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 22. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 23. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 24. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 25. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 26. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 27. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 28. ? @ 0x00007fbc6213eac3 29. ? @ 0x00007fbc621d0850 2025.07.28 11:54:12.134862 [ 3968 ] {} test_13.rmt2 (7f9b740d-015c-470e-8cc6-8ba33be0dc63): auto DB::StorageReplicatedMergeTree::processQueueEntry(ReplicatedMergeTreeQueue::SelectedEntryPtr)::(anonymous class)::operator()(LogEntryPtr &) const: Code: 86. DB::HTTPException: Received error from remote server http://146b4357c08d:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Ftest%2F01165%2Ftest_13%2Frmt%2Freplicas%2F1&part=20250728_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.6.10636.altinitytest (altinity build)) '. (RECEIVED_ERROR_FROM_REMOTE_IO_SERVER), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.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 const&, int&&, String const&, unsigned long&&, String const&) @ 0x000000000feda8d9 4. /build/src/IO/HTTPCommon.cpp:104: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x000000000feda6e2 5. /build/src/IO/HTTPCommon.cpp:93: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x000000000feda537 6. /build/src/IO/ReadWriteBufferFromHTTP.cpp:277: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x000000001184a4c4 7. /build/src/IO/ReadWriteBufferFromHTTP.cpp:285: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x000000001184a615 8. /build/src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x000000001184ae59 9. /build/src/IO/ReadWriteBufferFromHTTP.cpp:472: void std::__function::__policy_invoker::__call_impl[abi:se190107]>(std::__function::__policy_storage const*) @ 0x000000001184cedd 10. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001184858b 11. /build/src/IO/ReadWriteBufferFromHTTP.cpp:465: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x000000001184bf0b 12. /build/src/IO/ReadBuffer.h:60: DB::ReadBuffer::next() @ 0x000000000a148c7b 13. /build/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) @ 0x0000000011849fb2 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]>&)>&, 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&) @ 0x0000000011841980 15. /build/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) @ 0x000000001621208e 16. /build/src/Storages/StorageReplicatedMergeTree.cpp:5228: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl[abi:se190107] const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000015f9a5fe 17. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000015ed8bfd 18. /build/src/Storages/StorageReplicatedMergeTree.cpp:2514: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x0000000015ec9aab 19. /build/src/Storages/StorageReplicatedMergeTree.cpp:2349: DB::StorageReplicatedMergeTree::executeLogEntry(DB::ReplicatedMergeTreeLogEntry&) @ 0x0000000015eba91b 20. /build/src/Storages/StorageReplicatedMergeTree.cpp:3876: bool std::__function::__policy_invoker&)>::__call_impl[abi:se190107])::$_1, bool (std::shared_ptr&)>>(std::__function::__policy_storage const*, std::shared_ptr&) @ 0x0000000015f9837e 21. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000165d6fc3 22. /build/src/Storages/StorageReplicatedMergeTree.cpp:3872: DB::StorageReplicatedMergeTree::processQueueEntry(std::shared_ptr) @ 0x0000000015efc18a 23. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001624c1b2 24. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000162f9c70 25. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x00000000162fa55a 26. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc6653 27. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000000fccc4c3 28. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc3d92 29. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fcca080 30. ? @ 0x00007fbc6213eac3 31. ? @ 0x00007fbc621d0850 (version 25.3.6.10636.altinitytest (altinity build)) 2025.07.28 11:54:12.175425 [ 3283 ] {d1718042-ebe1-4fcd-aaf9-c56a0f86373c} executeQuery: Code: 1. DB::Exception: Resolved identifier 'item_id' in parent scope to expression 'l.item_id' with correlated column 'item_id'. In scope SELECT item_id FROM t1. (UNSUPPORTED_METHOD) (version 25.3.6.10636.altinitytest (altinity build)) (from [::1]:45566) (comment: 03255_parallel_replicas_join_algo_and_analyzer_4.sh) (query 5, line 7) (in query: --SELECT '----- enable_parallel_replicas=1 prefer_local_plan=1 parallel_replicas_prefer_local_join=1 -----'; SELECT sum(item_id) FROM ( SELECT item_id FROM t GROUP BY item_id ) AS l LEFT JOIN ( SELECT item_id FROM t1 ) AS r ON l.item_id = r.item_id ;), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/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 const&, String&&) @ 0x000000001404a1eb 4. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:1382: DB::QueryAnalyzer::tryResolveIdentifierInParentScopes(DB::IdentifierLookup const&, DB::IdentifierResolveScope&, DB::IdentifierResolveContext) @ 0x000000001402a8cc 5. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:1544: DB::QueryAnalyzer::tryResolveIdentifier(DB::IdentifierLookup const&, DB::IdentifierResolveScope&, DB::IdentifierResolveContext) @ 0x00000000140298dd 6. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3692: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000001401a2b4 7. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3980: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000014018e31 8. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:4304: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000014042fa7 9. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5605: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000014013749 10. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3870: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x00000000140199de 11. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5334: DB::QueryAnalyzer::resolveQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&) @ 0x00000000140454b0 12. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5142: DB::QueryAnalyzer::resolveJoin(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&) @ 0x0000000014046de9 13. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5361: DB::QueryAnalyzer::resolveQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&) @ 0x00000000140452d6 14. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5597: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000140136f0 15. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000140127f9 16. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000014011fce 17. /build/src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000001406ce8a 18. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000014973b42 19. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000001497268d 20. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000014974d24 21. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001492924b 22. /build/src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88641 23. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 24. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 25. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 26. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 27. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 28. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 29. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 30. ? @ 0x00007fbc6213eac3 31. ? @ 0x00007fbc621d0850 2025.07.28 11:54:12.228502 [ 3283 ] {} TCPHandler: Code: 1. DB::Exception: Resolved identifier 'item_id' in parent scope to expression 'l.item_id' with correlated column 'item_id'. In scope SELECT item_id FROM t1. (UNSUPPORTED_METHOD), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/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 const&, String&&) @ 0x000000001404a1eb 4. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:1382: DB::QueryAnalyzer::tryResolveIdentifierInParentScopes(DB::IdentifierLookup const&, DB::IdentifierResolveScope&, DB::IdentifierResolveContext) @ 0x000000001402a8cc 5. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:1544: DB::QueryAnalyzer::tryResolveIdentifier(DB::IdentifierLookup const&, DB::IdentifierResolveScope&, DB::IdentifierResolveContext) @ 0x00000000140298dd 6. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3692: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000001401a2b4 7. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3980: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000014018e31 8. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:4304: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000014042fa7 9. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5605: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000014013749 10. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3870: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x00000000140199de 11. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5334: DB::QueryAnalyzer::resolveQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&) @ 0x00000000140454b0 12. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5142: DB::QueryAnalyzer::resolveJoin(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&) @ 0x0000000014046de9 13. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5361: DB::QueryAnalyzer::resolveQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&) @ 0x00000000140452d6 14. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5597: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000140136f0 15. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000140127f9 16. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000014011fce 17. /build/src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000001406ce8a 18. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000014973b42 19. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000001497268d 20. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000014974d24 21. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001492924b 22. /build/src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88641 23. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 24. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 25. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 26. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 27. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 28. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 29. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 30. ? @ 0x00007fbc6213eac3 31. ? @ 0x00007fbc621d0850 2025.07.28 11:54:12.576715 [ 3961 ] {} test_13.rmt2 (7f9b740d-015c-470e-8cc6-8ba33be0dc63): auto DB::StorageReplicatedMergeTree::processQueueEntry(ReplicatedMergeTreeQueue::SelectedEntryPtr)::(anonymous class)::operator()(LogEntryPtr &) const: Code: 86. DB::HTTPException: Received error from remote server http://146b4357c08d:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Ftest%2F01165%2Ftest_13%2Frmt%2Freplicas%2F1&part=20250728_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.6.10636.altinitytest (altinity build)) '. (RECEIVED_ERROR_FROM_REMOTE_IO_SERVER), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.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 const&, int&&, String const&, unsigned long&&, String const&) @ 0x000000000feda8d9 4. /build/src/IO/HTTPCommon.cpp:104: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x000000000feda6e2 5. /build/src/IO/HTTPCommon.cpp:93: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x000000000feda537 6. /build/src/IO/ReadWriteBufferFromHTTP.cpp:277: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x000000001184a4c4 7. /build/src/IO/ReadWriteBufferFromHTTP.cpp:285: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x000000001184a615 8. /build/src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x000000001184ae59 9. /build/src/IO/ReadWriteBufferFromHTTP.cpp:472: void std::__function::__policy_invoker::__call_impl[abi:se190107]>(std::__function::__policy_storage const*) @ 0x000000001184cedd 10. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001184858b 11. /build/src/IO/ReadWriteBufferFromHTTP.cpp:465: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x000000001184bf0b 12. /build/src/IO/ReadBuffer.h:60: DB::ReadBuffer::next() @ 0x000000000a148c7b 13. /build/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) @ 0x0000000011849fb2 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]>&)>&, 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&) @ 0x0000000011841980 15. /build/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) @ 0x000000001621208e 16. /build/src/Storages/StorageReplicatedMergeTree.cpp:5228: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl[abi:se190107] const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000015f9a5fe 17. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000015ed8bfd 18. /build/src/Storages/StorageReplicatedMergeTree.cpp:2514: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x0000000015ec9aab 19. /build/src/Storages/StorageReplicatedMergeTree.cpp:2349: DB::StorageReplicatedMergeTree::executeLogEntry(DB::ReplicatedMergeTreeLogEntry&) @ 0x0000000015eba91b 20. /build/src/Storages/StorageReplicatedMergeTree.cpp:3876: bool std::__function::__policy_invoker&)>::__call_impl[abi:se190107])::$_1, bool (std::shared_ptr&)>>(std::__function::__policy_storage const*, std::shared_ptr&) @ 0x0000000015f9837e 21. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000165d6fc3 22. /build/src/Storages/StorageReplicatedMergeTree.cpp:3872: DB::StorageReplicatedMergeTree::processQueueEntry(std::shared_ptr) @ 0x0000000015efc18a 23. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001624c1b2 24. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000162f9c70 25. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x00000000162fa55a 26. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc6653 27. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000000fccc4c3 28. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc3d92 29. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fcca080 30. ? @ 0x00007fbc6213eac3 31. ? @ 0x00007fbc621d0850 (version 25.3.6.10636.altinitytest (altinity build)) 2025.07.28 11:54:12.613562 [ 11826 ] {c28df0a0-9cf2-43cf-8a9b-74807d8113d1} executeQuery: Code: 1. DB::Exception: Resolved identifier 'item_id' in parent scope to expression 'l.item_id' with correlated column 'item_id'. In scope SELECT item_id FROM t1 GROUP BY item_id. (UNSUPPORTED_METHOD) (version 25.3.6.10636.altinitytest (altinity build)) (from [::1]:45610) (comment: 03255_parallel_replicas_join_algo_and_analyzer_4.sh) (query 5, line 7) (in query: --SELECT '----- enable_parallel_replicas=0 prefer_local_plan=1 parallel_replicas_prefer_local_join=1 -----'; SELECT sum(item_id) FROM ( SELECT item_id FROM t ) AS l LEFT JOIN ( SELECT item_id FROM t1 GROUP BY item_id ) AS r ON l.item_id = r.item_id ;), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/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 const&, String&&) @ 0x000000001404a1eb 4. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:1382: DB::QueryAnalyzer::tryResolveIdentifierInParentScopes(DB::IdentifierLookup const&, DB::IdentifierResolveScope&, DB::IdentifierResolveContext) @ 0x000000001402a8cc 5. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:1544: DB::QueryAnalyzer::tryResolveIdentifier(DB::IdentifierLookup const&, DB::IdentifierResolveScope&, DB::IdentifierResolveContext) @ 0x00000000140298dd 6. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3692: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000001401a2b4 7. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3980: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000014018e31 8. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:4304: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000014042fa7 9. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5605: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000014013749 10. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3870: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x00000000140199de 11. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5334: DB::QueryAnalyzer::resolveQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&) @ 0x00000000140454b0 12. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5142: DB::QueryAnalyzer::resolveJoin(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&) @ 0x0000000014046de9 13. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5361: DB::QueryAnalyzer::resolveQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&) @ 0x00000000140452d6 14. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5597: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000140136f0 15. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000140127f9 16. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000014011fce 17. /build/src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000001406ce8a 18. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000014973b42 19. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000001497268d 20. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000014974d24 21. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001492924b 22. /build/src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88641 23. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 24. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 25. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 26. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 27. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 28. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 29. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 30. ? @ 0x00007fbc6213eac3 31. ? @ 0x00007fbc621d0850 2025.07.28 11:54:12.629653 [ 11826 ] {} TCPHandler: Code: 1. DB::Exception: Resolved identifier 'item_id' in parent scope to expression 'l.item_id' with correlated column 'item_id'. In scope SELECT item_id FROM t1 GROUP BY item_id. (UNSUPPORTED_METHOD), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/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 const&, String&&) @ 0x000000001404a1eb 4. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:1382: DB::QueryAnalyzer::tryResolveIdentifierInParentScopes(DB::IdentifierLookup const&, DB::IdentifierResolveScope&, DB::IdentifierResolveContext) @ 0x000000001402a8cc 5. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:1544: DB::QueryAnalyzer::tryResolveIdentifier(DB::IdentifierLookup const&, DB::IdentifierResolveScope&, DB::IdentifierResolveContext) @ 0x00000000140298dd 6. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3692: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000001401a2b4 7. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3980: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000014018e31 8. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:4304: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000014042fa7 9. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5605: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000014013749 10. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3870: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x00000000140199de 11. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5334: DB::QueryAnalyzer::resolveQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&) @ 0x00000000140454b0 12. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5142: DB::QueryAnalyzer::resolveJoin(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&) @ 0x0000000014046de9 13. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5361: DB::QueryAnalyzer::resolveQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&) @ 0x00000000140452d6 14. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5597: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000140136f0 15. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000140127f9 16. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000014011fce 17. /build/src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000001406ce8a 18. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000014973b42 19. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000001497268d 20. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000014974d24 21. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001492924b 22. /build/src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88641 23. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 24. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 25. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 26. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 27. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 28. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 29. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 30. ? @ 0x00007fbc6213eac3 31. ? @ 0x00007fbc621d0850 2025.07.28 11:54:12.633020 [ 17557 ] {cb94f0fd-a112-496b-8587-f0fd09b94b17} executeQuery: Code: 43. DB::Exception: Function untuple can't have lambda-expressions as arguments. (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.6.10636.altinitytest (altinity build)) (from [::1]:45602) (comment: 03142_untuple_crash.sql) (query 2, line 2) (in query: SELECT untuple(x -> 0) -- { serverError ILLEGAL_TYPE_OF_ARGUMENT } ), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000000a074fcb 4. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3205: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000140368af 5. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3838: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000014019a9e 6. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3980: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000014018e31 7. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:4304: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000014042fa7 8. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5605: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000014013749 9. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000140127f9 10. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000014011fce 11. /build/src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000001406ce8a 12. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000014973b42 13. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000001497268d 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000014974d24 15. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001492924b 16. /build/src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88641 17. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 18. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 19. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 20. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 21. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 22. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 23. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 24. ? @ 0x00007fbc6213eac3 25. ? @ 0x00007fbc621d0850 2025.07.28 11:54:12.650114 [ 17557 ] {} TCPHandler: Code: 43. DB::Exception: Function untuple can't have lambda-expressions as arguments. (ILLEGAL_TYPE_OF_ARGUMENT), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000000a074fcb 4. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3205: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000140368af 5. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3838: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000014019a9e 6. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3980: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000014018e31 7. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:4304: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000014042fa7 8. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5605: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000014013749 9. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000140127f9 10. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000014011fce 11. /build/src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000001406ce8a 12. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000014973b42 13. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000001497268d 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000014974d24 15. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001492924b 16. /build/src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88641 17. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 18. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 19. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 20. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 21. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 22. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 23. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 24. ? @ 0x00007fbc6213eac3 25. ? @ 0x00007fbc621d0850 2025.07.28 11:54:12.672138 [ 3963 ] {} test_13.rmt2 (7f9b740d-015c-470e-8cc6-8ba33be0dc63): auto DB::StorageReplicatedMergeTree::processQueueEntry(ReplicatedMergeTreeQueue::SelectedEntryPtr)::(anonymous class)::operator()(LogEntryPtr &) const: Code: 86. DB::HTTPException: Received error from remote server http://146b4357c08d:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Ftest%2F01165%2Ftest_13%2Frmt%2Freplicas%2F1&part=20250728_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.6.10636.altinitytest (altinity build)) '. (RECEIVED_ERROR_FROM_REMOTE_IO_SERVER), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.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 const&, int&&, String const&, unsigned long&&, String const&) @ 0x000000000feda8d9 4. /build/src/IO/HTTPCommon.cpp:104: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x000000000feda6e2 5. /build/src/IO/HTTPCommon.cpp:93: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x000000000feda537 6. /build/src/IO/ReadWriteBufferFromHTTP.cpp:277: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x000000001184a4c4 7. /build/src/IO/ReadWriteBufferFromHTTP.cpp:285: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x000000001184a615 8. /build/src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x000000001184ae59 9. /build/src/IO/ReadWriteBufferFromHTTP.cpp:472: void std::__function::__policy_invoker::__call_impl[abi:se190107]>(std::__function::__policy_storage const*) @ 0x000000001184cedd 10. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001184858b 11. /build/src/IO/ReadWriteBufferFromHTTP.cpp:465: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x000000001184bf0b 12. /build/src/IO/ReadBuffer.h:60: DB::ReadBuffer::next() @ 0x000000000a148c7b 13. /build/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) @ 0x0000000011849fb2 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]>&)>&, 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&) @ 0x0000000011841980 15. /build/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) @ 0x000000001621208e 16. /build/src/Storages/StorageReplicatedMergeTree.cpp:5228: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl[abi:se190107] const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000015f9a5fe 17. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000015ed8bfd 18. /build/src/Storages/StorageReplicatedMergeTree.cpp:2514: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x0000000015ec9aab 19. /build/src/Storages/StorageReplicatedMergeTree.cpp:2349: DB::StorageReplicatedMergeTree::executeLogEntry(DB::ReplicatedMergeTreeLogEntry&) @ 0x0000000015eba91b 20. /build/src/Storages/StorageReplicatedMergeTree.cpp:3876: bool std::__function::__policy_invoker&)>::__call_impl[abi:se190107])::$_1, bool (std::shared_ptr&)>>(std::__function::__policy_storage const*, std::shared_ptr&) @ 0x0000000015f9837e 21. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000165d6fc3 22. /build/src/Storages/StorageReplicatedMergeTree.cpp:3872: DB::StorageReplicatedMergeTree::processQueueEntry(std::shared_ptr) @ 0x0000000015efc18a 23. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001624c1b2 24. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000162f9c70 25. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x00000000162fa55a 26. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc6653 27. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000000fccc4c3 28. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc3d92 29. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fcca080 30. ? @ 0x00007fbc6213eac3 31. ? @ 0x00007fbc621d0850 (version 25.3.6.10636.altinitytest (altinity build)) 2025.07.28 11:54:12.969651 [ 3283 ] {6050d066-8b5f-4eb0-a2a3-8635bc4863e0} executeQuery: Code: 1. DB::Exception: Resolved identifier 'item_id' in parent scope to expression 'l.item_id' with correlated column 'item_id'. In scope SELECT item_id FROM t1 GROUP BY item_id. (UNSUPPORTED_METHOD) (version 25.3.6.10636.altinitytest (altinity build)) (from [::1]:45616) (comment: 03255_parallel_replicas_join_algo_and_analyzer_4.sh) (query 5, line 7) (in query: --SELECT '----- enable_parallel_replicas=1 prefer_local_plan=1 parallel_replicas_prefer_local_join=1 -----'; SELECT sum(item_id) FROM ( SELECT item_id FROM t ) AS l LEFT JOIN ( SELECT item_id FROM t1 GROUP BY item_id ) AS r ON l.item_id = r.item_id ;), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/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 const&, String&&) @ 0x000000001404a1eb 4. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:1382: DB::QueryAnalyzer::tryResolveIdentifierInParentScopes(DB::IdentifierLookup const&, DB::IdentifierResolveScope&, DB::IdentifierResolveContext) @ 0x000000001402a8cc 5. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:1544: DB::QueryAnalyzer::tryResolveIdentifier(DB::IdentifierLookup const&, DB::IdentifierResolveScope&, DB::IdentifierResolveContext) @ 0x00000000140298dd 6. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3692: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000001401a2b4 7. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3980: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000014018e31 8. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:4304: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000014042fa7 9. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5605: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000014013749 10. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3870: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x00000000140199de 11. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5334: DB::QueryAnalyzer::resolveQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&) @ 0x00000000140454b0 12. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5142: DB::QueryAnalyzer::resolveJoin(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&) @ 0x0000000014046de9 13. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5361: DB::QueryAnalyzer::resolveQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&) @ 0x00000000140452d6 14. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5597: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000140136f0 15. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000140127f9 16. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000014011fce 17. /build/src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000001406ce8a 18. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000014973b42 19. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000001497268d 20. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000014974d24 21. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001492924b 22. /build/src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88641 23. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 24. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 25. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 26. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 27. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 28. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 29. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 30. ? @ 0x00007fbc6213eac3 31. ? @ 0x00007fbc621d0850 2025.07.28 11:54:13.007533 [ 3283 ] {} TCPHandler: Code: 1. DB::Exception: Resolved identifier 'item_id' in parent scope to expression 'l.item_id' with correlated column 'item_id'. In scope SELECT item_id FROM t1 GROUP BY item_id. (UNSUPPORTED_METHOD), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/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 const&, String&&) @ 0x000000001404a1eb 4. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:1382: DB::QueryAnalyzer::tryResolveIdentifierInParentScopes(DB::IdentifierLookup const&, DB::IdentifierResolveScope&, DB::IdentifierResolveContext) @ 0x000000001402a8cc 5. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:1544: DB::QueryAnalyzer::tryResolveIdentifier(DB::IdentifierLookup const&, DB::IdentifierResolveScope&, DB::IdentifierResolveContext) @ 0x00000000140298dd 6. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3692: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000001401a2b4 7. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3980: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000014018e31 8. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:4304: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000014042fa7 9. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5605: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000014013749 10. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3870: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x00000000140199de 11. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5334: DB::QueryAnalyzer::resolveQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&) @ 0x00000000140454b0 12. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5142: DB::QueryAnalyzer::resolveJoin(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&) @ 0x0000000014046de9 13. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5361: DB::QueryAnalyzer::resolveQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&) @ 0x00000000140452d6 14. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5597: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000140136f0 15. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000140127f9 16. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000014011fce 17. /build/src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000001406ce8a 18. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000014973b42 19. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000001497268d 20. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000014974d24 21. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001492924b 22. /build/src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88641 23. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 24. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 25. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 26. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 27. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 28. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 29. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 30. ? @ 0x00007fbc6213eac3 31. ? @ 0x00007fbc621d0850 2025.07.28 11:54:13.439003 [ 11826 ] {bb33d02a-bd5c-4973-817d-a3ee0f2cc71e} executeQuery: Code: 628. DB::Exception: Can not use OFFSET FETCH clause without ORDER BY. (OFFSET_FETCH_WITHOUT_ORDER_BY) (version 25.3.6.10636.altinitytest (altinity build)) (from [::ffff:127.0.0.1]:34126) (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. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000000a074fcb 4. /build/src/Parsers/ParserSelectQuery.cpp:430: DB::ParserSelectQuery::parseImpl(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x0000000017a7323c 5. /build/src/Parsers/IParserBase.cpp:14: DB::IParserBase::parse(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x0000000017a36cf0 6. /build/src/Parsers/ParserUnionQueryElement.cpp:13: DB::ParserUnionQueryElement::parseImpl(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x0000000017a8a222 7. /build/src/Parsers/IParserBase.cpp:14: DB::IParserBase::parse(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x0000000017a36cf0 8. /build/src/Parsers/ExpressionListParsers.cpp:82: DB::ParserUnionList::parseImpl(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&)::$_0::operator()() const @ 0x0000000017a23244 9. /build/src/Parsers/ExpressionListParsers.h:89: DB::ParserUnionList::parseImpl(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x0000000017a1ab73 10. /build/src/Parsers/IParserBase.cpp:14: DB::IParserBase::parse(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x0000000017a36cf0 11. /build/src/Parsers/ParserSelectWithUnionQuery.cpp:15: DB::ParserSelectWithUnionQuery::parseImpl(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x0000000017a73745 12. /build/src/Parsers/IParserBase.cpp:14: DB::IParserBase::parse(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x0000000017a36cf0 13. /build/src/Parsers/ParserQueryWithOutput.cpp:74: DB::ParserQueryWithOutput::parseImpl(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x0000000017a645a3 14. /build/src/Parsers/IParserBase.cpp:14: DB::IParserBase::parse(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x0000000017a36cf0 15. /build/src/Parsers/ParserQuery.cpp:77: DB::ParserQuery::parseImpl(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x0000000017a5dde6 16. /build/src/Parsers/IParserBase.cpp:14: DB::IParserBase::parse(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x0000000017a36cf0 17. /build/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) @ 0x0000000017a95a80 18. /build/src/Parsers/parseQuery.cpp:404: DB::parseQueryAndMovePosition(DB::IParser&, char const*&, char const*, String const&, bool, unsigned long, unsigned long, unsigned long) @ 0x0000000017a96ac6 19. /build/src/Parsers/parseQuery.cpp:424: DB::parseQuery(DB::IParser&, char const*, char const*, String const&, unsigned long, unsigned long, unsigned long) @ 0x0000000017a96bbe 20. /build/src/Interpreters/executeQuery.cpp:955: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c8533e 21. /build/src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x0000000014c8ca7b 22. /build/src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000001686da12 23. /build/src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x0000000016870807 24. /build/src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x0000000016907e99 25. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 26. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 27. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 28. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 29. ? @ 0x00007fbc6213eac3 30. ? @ 0x00007fbc621d0850 2025.07.28 11:54:13.441473 [ 11826 ] {bb33d02a-bd5c-4973-817d-a3ee0f2cc71e} 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. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000000a074fcb 4. /build/src/Parsers/ParserSelectQuery.cpp:430: DB::ParserSelectQuery::parseImpl(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x0000000017a7323c 5. /build/src/Parsers/IParserBase.cpp:14: DB::IParserBase::parse(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x0000000017a36cf0 6. /build/src/Parsers/ParserUnionQueryElement.cpp:13: DB::ParserUnionQueryElement::parseImpl(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x0000000017a8a222 7. /build/src/Parsers/IParserBase.cpp:14: DB::IParserBase::parse(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x0000000017a36cf0 8. /build/src/Parsers/ExpressionListParsers.cpp:82: DB::ParserUnionList::parseImpl(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&)::$_0::operator()() const @ 0x0000000017a23244 9. /build/src/Parsers/ExpressionListParsers.h:89: DB::ParserUnionList::parseImpl(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x0000000017a1ab73 10. /build/src/Parsers/IParserBase.cpp:14: DB::IParserBase::parse(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x0000000017a36cf0 11. /build/src/Parsers/ParserSelectWithUnionQuery.cpp:15: DB::ParserSelectWithUnionQuery::parseImpl(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x0000000017a73745 12. /build/src/Parsers/IParserBase.cpp:14: DB::IParserBase::parse(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x0000000017a36cf0 13. /build/src/Parsers/ParserQueryWithOutput.cpp:74: DB::ParserQueryWithOutput::parseImpl(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x0000000017a645a3 14. /build/src/Parsers/IParserBase.cpp:14: DB::IParserBase::parse(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x0000000017a36cf0 15. /build/src/Parsers/ParserQuery.cpp:77: DB::ParserQuery::parseImpl(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x0000000017a5dde6 16. /build/src/Parsers/IParserBase.cpp:14: DB::IParserBase::parse(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x0000000017a36cf0 17. /build/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) @ 0x0000000017a95a80 18. /build/src/Parsers/parseQuery.cpp:404: DB::parseQueryAndMovePosition(DB::IParser&, char const*&, char const*, String const&, bool, unsigned long, unsigned long, unsigned long) @ 0x0000000017a96ac6 19. /build/src/Parsers/parseQuery.cpp:424: DB::parseQuery(DB::IParser&, char const*, char const*, String const&, unsigned long, unsigned long, unsigned long) @ 0x0000000017a96bbe 20. /build/src/Interpreters/executeQuery.cpp:955: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c8533e 21. /build/src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x0000000014c8ca7b 22. /build/src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000001686da12 23. /build/src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x0000000016870807 24. /build/src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x0000000016907e99 25. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 26. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 27. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 28. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 29. ? @ 0x00007fbc6213eac3 30. ? @ 0x00007fbc621d0850 (version 25.3.6.10636.altinitytest (altinity build)) 2025.07.28 11:54:13.465259 [ 3283 ] {5b102b1e-3c9e-4161-94ef-3d5986be3865} executeQuery: Code: 1. DB::Exception: Resolved identifier 'item_id' in parent scope to expression 'l.item_id' with correlated column 'item_id'. In scope SELECT item_id FROM t1. (UNSUPPORTED_METHOD) (version 25.3.6.10636.altinitytest (altinity build)) (from [::1]:45648) (comment: 03255_parallel_replicas_join_algo_and_analyzer_4.sh) (query 5, line 7) (in query: --SELECT '----- enable_parallel_replicas=0 prefer_local_plan=1 parallel_replicas_prefer_local_join=1 -----'; SELECT sum(item_id) FROM ( SELECT item_id, price_sold FROM t ) AS l LEFT JOIN ( SELECT item_id FROM t1 ) AS r ON l.item_id = r.item_id GROUP BY price_sold ORDER BY price_sold ;), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/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 const&, String&&) @ 0x000000001404a1eb 4. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:1382: DB::QueryAnalyzer::tryResolveIdentifierInParentScopes(DB::IdentifierLookup const&, DB::IdentifierResolveScope&, DB::IdentifierResolveContext) @ 0x000000001402a8cc 5. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:1544: DB::QueryAnalyzer::tryResolveIdentifier(DB::IdentifierLookup const&, DB::IdentifierResolveScope&, DB::IdentifierResolveContext) @ 0x00000000140298dd 6. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3692: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000001401a2b4 7. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3980: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000014018e31 8. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:4304: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000014042fa7 9. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5605: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000014013749 10. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3870: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x00000000140199de 11. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5334: DB::QueryAnalyzer::resolveQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&) @ 0x00000000140454b0 12. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5142: DB::QueryAnalyzer::resolveJoin(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&) @ 0x0000000014046de9 13. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5361: DB::QueryAnalyzer::resolveQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&) @ 0x00000000140452d6 14. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5597: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000140136f0 15. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000140127f9 16. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000014011fce 17. /build/src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000001406ce8a 18. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000014973b42 19. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000001497268d 20. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000014974d24 21. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001492924b 22. /build/src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88641 23. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 24. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 25. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 26. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 27. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 28. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 29. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 30. ? @ 0x00007fbc6213eac3 31. ? @ 0x00007fbc621d0850 2025.07.28 11:54:13.496770 [ 3283 ] {} TCPHandler: Code: 1. DB::Exception: Resolved identifier 'item_id' in parent scope to expression 'l.item_id' with correlated column 'item_id'. In scope SELECT item_id FROM t1. (UNSUPPORTED_METHOD), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/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 const&, String&&) @ 0x000000001404a1eb 4. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:1382: DB::QueryAnalyzer::tryResolveIdentifierInParentScopes(DB::IdentifierLookup const&, DB::IdentifierResolveScope&, DB::IdentifierResolveContext) @ 0x000000001402a8cc 5. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:1544: DB::QueryAnalyzer::tryResolveIdentifier(DB::IdentifierLookup const&, DB::IdentifierResolveScope&, DB::IdentifierResolveContext) @ 0x00000000140298dd 6. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3692: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000001401a2b4 7. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3980: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000014018e31 8. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:4304: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000014042fa7 9. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5605: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000014013749 10. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3870: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x00000000140199de 11. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5334: DB::QueryAnalyzer::resolveQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&) @ 0x00000000140454b0 12. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5142: DB::QueryAnalyzer::resolveJoin(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&) @ 0x0000000014046de9 13. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5361: DB::QueryAnalyzer::resolveQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&) @ 0x00000000140452d6 14. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5597: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000140136f0 15. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000140127f9 16. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000014011fce 17. /build/src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000001406ce8a 18. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000014973b42 19. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000001497268d 20. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000014974d24 21. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001492924b 22. /build/src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88641 23. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 24. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 25. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 26. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 27. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 28. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 29. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 30. ? @ 0x00007fbc6213eac3 31. ? @ 0x00007fbc621d0850 2025.07.28 11:54:13.726553 [ 3967 ] {} test_13.rmt2 (7f9b740d-015c-470e-8cc6-8ba33be0dc63): auto DB::StorageReplicatedMergeTree::processQueueEntry(ReplicatedMergeTreeQueue::SelectedEntryPtr)::(anonymous class)::operator()(LogEntryPtr &) const: Code: 86. DB::HTTPException: Received error from remote server http://146b4357c08d:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Ftest%2F01165%2Ftest_13%2Frmt%2Freplicas%2F1&part=20250728_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.6.10636.altinitytest (altinity build)) '. (RECEIVED_ERROR_FROM_REMOTE_IO_SERVER), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.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 const&, int&&, String const&, unsigned long&&, String const&) @ 0x000000000feda8d9 4. /build/src/IO/HTTPCommon.cpp:104: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x000000000feda6e2 5. /build/src/IO/HTTPCommon.cpp:93: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x000000000feda537 6. /build/src/IO/ReadWriteBufferFromHTTP.cpp:277: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x000000001184a4c4 7. /build/src/IO/ReadWriteBufferFromHTTP.cpp:285: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x000000001184a615 8. /build/src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x000000001184ae59 9. /build/src/IO/ReadWriteBufferFromHTTP.cpp:472: void std::__function::__policy_invoker::__call_impl[abi:se190107]>(std::__function::__policy_storage const*) @ 0x000000001184cedd 10. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001184858b 11. /build/src/IO/ReadWriteBufferFromHTTP.cpp:465: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x000000001184bf0b 12. /build/src/IO/ReadBuffer.h:60: DB::ReadBuffer::next() @ 0x000000000a148c7b 13. /build/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) @ 0x0000000011849fb2 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]>&)>&, 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&) @ 0x0000000011841980 15. /build/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) @ 0x000000001621208e 16. /build/src/Storages/StorageReplicatedMergeTree.cpp:5228: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl[abi:se190107] const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000015f9a5fe 17. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000015ed8bfd 18. /build/src/Storages/StorageReplicatedMergeTree.cpp:2514: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x0000000015ec9aab 19. /build/src/Storages/StorageReplicatedMergeTree.cpp:2349: DB::StorageReplicatedMergeTree::executeLogEntry(DB::ReplicatedMergeTreeLogEntry&) @ 0x0000000015eba91b 20. /build/src/Storages/StorageReplicatedMergeTree.cpp:3876: bool std::__function::__policy_invoker&)>::__call_impl[abi:se190107])::$_1, bool (std::shared_ptr&)>>(std::__function::__policy_storage const*, std::shared_ptr&) @ 0x0000000015f9837e 21. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000165d6fc3 22. /build/src/Storages/StorageReplicatedMergeTree.cpp:3872: DB::StorageReplicatedMergeTree::processQueueEntry(std::shared_ptr) @ 0x0000000015efc18a 23. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001624c1b2 24. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000162f9c70 25. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x00000000162fa55a 26. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc6653 27. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000000fccc4c3 28. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc3d92 29. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fcca080 30. ? @ 0x00007fbc6213eac3 31. ? @ 0x00007fbc621d0850 (version 25.3.6.10636.altinitytest (altinity build)) 2025.07.28 11:54:13.748831 [ 3283 ] {98e6c5e1-a091-4658-94ec-c54ed9774ed7} executeQuery: Code: 1. DB::Exception: Resolved identifier 'item_id' in parent scope to expression 'l.item_id' with correlated column 'item_id'. In scope SELECT item_id FROM t1. (UNSUPPORTED_METHOD) (version 25.3.6.10636.altinitytest (altinity build)) (from [::1]:45660) (comment: 03255_parallel_replicas_join_algo_and_analyzer_4.sh) (query 5, line 7) (in query: --SELECT '----- enable_parallel_replicas=1 prefer_local_plan=1 parallel_replicas_prefer_local_join=1 -----'; SELECT sum(item_id) FROM ( SELECT item_id, price_sold FROM t ) AS l LEFT JOIN ( SELECT item_id FROM t1 ) AS r ON l.item_id = r.item_id GROUP BY price_sold ORDER BY price_sold ;), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/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 const&, String&&) @ 0x000000001404a1eb 4. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:1382: DB::QueryAnalyzer::tryResolveIdentifierInParentScopes(DB::IdentifierLookup const&, DB::IdentifierResolveScope&, DB::IdentifierResolveContext) @ 0x000000001402a8cc 5. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:1544: DB::QueryAnalyzer::tryResolveIdentifier(DB::IdentifierLookup const&, DB::IdentifierResolveScope&, DB::IdentifierResolveContext) @ 0x00000000140298dd 6. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3692: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000001401a2b4 7. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3980: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000014018e31 8. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:4304: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000014042fa7 9. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5605: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000014013749 10. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3870: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x00000000140199de 11. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5334: DB::QueryAnalyzer::resolveQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&) @ 0x00000000140454b0 12. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5142: DB::QueryAnalyzer::resolveJoin(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&) @ 0x0000000014046de9 13. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5361: DB::QueryAnalyzer::resolveQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&) @ 0x00000000140452d6 14. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5597: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000140136f0 15. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000140127f9 16. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000014011fce 17. /build/src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000001406ce8a 18. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000014973b42 19. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000001497268d 20. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000014974d24 21. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001492924b 22. /build/src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88641 23. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 24. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 25. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 26. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 27. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 28. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 29. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 30. ? @ 0x00007fbc6213eac3 31. ? @ 0x00007fbc621d0850 2025.07.28 11:54:13.772845 [ 3283 ] {} TCPHandler: Code: 1. DB::Exception: Resolved identifier 'item_id' in parent scope to expression 'l.item_id' with correlated column 'item_id'. In scope SELECT item_id FROM t1. (UNSUPPORTED_METHOD), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/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 const&, String&&) @ 0x000000001404a1eb 4. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:1382: DB::QueryAnalyzer::tryResolveIdentifierInParentScopes(DB::IdentifierLookup const&, DB::IdentifierResolveScope&, DB::IdentifierResolveContext) @ 0x000000001402a8cc 5. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:1544: DB::QueryAnalyzer::tryResolveIdentifier(DB::IdentifierLookup const&, DB::IdentifierResolveScope&, DB::IdentifierResolveContext) @ 0x00000000140298dd 6. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3692: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000001401a2b4 7. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3980: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000014018e31 8. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:4304: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000014042fa7 9. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5605: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000014013749 10. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3870: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x00000000140199de 11. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5334: DB::QueryAnalyzer::resolveQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&) @ 0x00000000140454b0 12. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5142: DB::QueryAnalyzer::resolveJoin(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&) @ 0x0000000014046de9 13. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5361: DB::QueryAnalyzer::resolveQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&) @ 0x00000000140452d6 14. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5597: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000140136f0 15. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000140127f9 16. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000014011fce 17. /build/src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000001406ce8a 18. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000014973b42 19. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000001497268d 20. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000014974d24 21. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001492924b 22. /build/src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88641 23. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 24. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 25. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 26. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 27. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 28. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 29. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 30. ? @ 0x00007fbc6213eac3 31. ? @ 0x00007fbc621d0850 2025.07.28 11:54:14.187035 [ 3283 ] {a89ae3a1-471c-4092-9484-bdac0f55dde8} executeQuery: Code: 1. DB::Exception: Resolved identifier 'item_id' in parent scope to expression 'l.item_id' with correlated column 'item_id'. In scope SELECT item_id FROM t1. (UNSUPPORTED_METHOD) (version 25.3.6.10636.altinitytest (altinity build)) (from [::1]:45686) (comment: 03255_parallel_replicas_join_algo_and_analyzer_4.sh) (query 5, line 7) (in query: --SELECT '----- enable_parallel_replicas=0 prefer_local_plan=0 parallel_replicas_prefer_local_join=0 -----'; SELECT sum(item_id) FROM ( SELECT item_id FROM t GROUP BY item_id ) AS l LEFT JOIN ( SELECT item_id FROM t1 ) AS r ON l.item_id = r.item_id ;), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/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 const&, String&&) @ 0x000000001404a1eb 4. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:1382: DB::QueryAnalyzer::tryResolveIdentifierInParentScopes(DB::IdentifierLookup const&, DB::IdentifierResolveScope&, DB::IdentifierResolveContext) @ 0x000000001402a8cc 5. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:1544: DB::QueryAnalyzer::tryResolveIdentifier(DB::IdentifierLookup const&, DB::IdentifierResolveScope&, DB::IdentifierResolveContext) @ 0x00000000140298dd 6. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3692: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000001401a2b4 7. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3980: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000014018e31 8. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:4304: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000014042fa7 9. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5605: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000014013749 10. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3870: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x00000000140199de 11. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5334: DB::QueryAnalyzer::resolveQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&) @ 0x00000000140454b0 12. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5142: DB::QueryAnalyzer::resolveJoin(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&) @ 0x0000000014046de9 13. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5361: DB::QueryAnalyzer::resolveQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&) @ 0x00000000140452d6 14. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5597: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000140136f0 15. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000140127f9 16. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000014011fce 17. /build/src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000001406ce8a 18. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000014973b42 19. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000001497268d 20. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000014974d24 21. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001492924b 22. /build/src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88641 23. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 24. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 25. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 26. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 27. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 28. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 29. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 30. ? @ 0x00007fbc6213eac3 31. ? @ 0x00007fbc621d0850 2025.07.28 11:54:14.214254 [ 3963 ] {} test_13.rmt2 (7f9b740d-015c-470e-8cc6-8ba33be0dc63): auto DB::StorageReplicatedMergeTree::processQueueEntry(ReplicatedMergeTreeQueue::SelectedEntryPtr)::(anonymous class)::operator()(LogEntryPtr &) const: Code: 86. DB::HTTPException: Received error from remote server http://146b4357c08d:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Ftest%2F01165%2Ftest_13%2Frmt%2Freplicas%2F1&part=20250728_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.6.10636.altinitytest (altinity build)) '. (RECEIVED_ERROR_FROM_REMOTE_IO_SERVER), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.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 const&, int&&, String const&, unsigned long&&, String const&) @ 0x000000000feda8d9 4. /build/src/IO/HTTPCommon.cpp:104: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x000000000feda6e2 5. /build/src/IO/HTTPCommon.cpp:93: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x000000000feda537 6. /build/src/IO/ReadWriteBufferFromHTTP.cpp:277: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x000000001184a4c4 7. /build/src/IO/ReadWriteBufferFromHTTP.cpp:285: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x000000001184a615 8. /build/src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x000000001184ae59 9. /build/src/IO/ReadWriteBufferFromHTTP.cpp:472: void std::__function::__policy_invoker::__call_impl[abi:se190107]>(std::__function::__policy_storage const*) @ 0x000000001184cedd 10. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001184858b 11. /build/src/IO/ReadWriteBufferFromHTTP.cpp:465: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x000000001184bf0b 12. /build/src/IO/ReadBuffer.h:60: DB::ReadBuffer::next() @ 0x000000000a148c7b 13. /build/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) @ 0x0000000011849fb2 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]>&)>&, 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&) @ 0x0000000011841980 15. /build/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) @ 0x000000001621208e 16. /build/src/Storages/StorageReplicatedMergeTree.cpp:5228: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl[abi:se190107] const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000015f9a5fe 17. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000015ed8bfd 18. /build/src/Storages/StorageReplicatedMergeTree.cpp:2514: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x0000000015ec9aab 19. /build/src/Storages/StorageReplicatedMergeTree.cpp:2349: DB::StorageReplicatedMergeTree::executeLogEntry(DB::ReplicatedMergeTreeLogEntry&) @ 0x0000000015eba91b 20. /build/src/Storages/StorageReplicatedMergeTree.cpp:3876: bool std::__function::__policy_invoker&)>::__call_impl[abi:se190107])::$_1, bool (std::shared_ptr&)>>(std::__function::__policy_storage const*, std::shared_ptr&) @ 0x0000000015f9837e 21. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000165d6fc3 22. /build/src/Storages/StorageReplicatedMergeTree.cpp:3872: DB::StorageReplicatedMergeTree::processQueueEntry(std::shared_ptr) @ 0x0000000015efc18a 23. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001624c1b2 24. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000162f9c70 25. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x00000000162fa55a 26. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc6653 27. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000000fccc4c3 28. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc3d92 29. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fcca080 30. ? @ 0x00007fbc6213eac3 31. ? @ 0x00007fbc621d0850 (version 25.3.6.10636.altinitytest (altinity build)) 2025.07.28 11:54:14.232486 [ 3283 ] {} TCPHandler: Code: 1. DB::Exception: Resolved identifier 'item_id' in parent scope to expression 'l.item_id' with correlated column 'item_id'. In scope SELECT item_id FROM t1. (UNSUPPORTED_METHOD), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/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 const&, String&&) @ 0x000000001404a1eb 4. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:1382: DB::QueryAnalyzer::tryResolveIdentifierInParentScopes(DB::IdentifierLookup const&, DB::IdentifierResolveScope&, DB::IdentifierResolveContext) @ 0x000000001402a8cc 5. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:1544: DB::QueryAnalyzer::tryResolveIdentifier(DB::IdentifierLookup const&, DB::IdentifierResolveScope&, DB::IdentifierResolveContext) @ 0x00000000140298dd 6. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3692: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000001401a2b4 7. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3980: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000014018e31 8. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:4304: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000014042fa7 9. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5605: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000014013749 10. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3870: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x00000000140199de 11. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5334: DB::QueryAnalyzer::resolveQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&) @ 0x00000000140454b0 12. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5142: DB::QueryAnalyzer::resolveJoin(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&) @ 0x0000000014046de9 13. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5361: DB::QueryAnalyzer::resolveQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&) @ 0x00000000140452d6 14. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5597: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000140136f0 15. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000140127f9 16. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000014011fce 17. /build/src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000001406ce8a 18. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000014973b42 19. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000001497268d 20. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000014974d24 21. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001492924b 22. /build/src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88641 23. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 24. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 25. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 26. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 27. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 28. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 29. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 30. ? @ 0x00007fbc6213eac3 31. ? @ 0x00007fbc621d0850 2025.07.28 11:54:14.621709 [ 3283 ] {2c5581d5-a34e-4e3d-862a-e9a4c1651c13} executeQuery: Code: 1. DB::Exception: Resolved identifier 'item_id' in parent scope to expression 'l.item_id' with correlated column 'item_id'. In scope SELECT item_id FROM t1. (UNSUPPORTED_METHOD) (version 25.3.6.10636.altinitytest (altinity build)) (from [::1]:45706) (comment: 03255_parallel_replicas_join_algo_and_analyzer_4.sh) (query 5, line 7) (in query: --SELECT '----- enable_parallel_replicas=1 prefer_local_plan=0 parallel_replicas_prefer_local_join=0 -----'; SELECT sum(item_id) FROM ( SELECT item_id FROM t GROUP BY item_id ) AS l LEFT JOIN ( SELECT item_id FROM t1 ) AS r ON l.item_id = r.item_id ;), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/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 const&, String&&) @ 0x000000001404a1eb 4. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:1382: DB::QueryAnalyzer::tryResolveIdentifierInParentScopes(DB::IdentifierLookup const&, DB::IdentifierResolveScope&, DB::IdentifierResolveContext) @ 0x000000001402a8cc 5. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:1544: DB::QueryAnalyzer::tryResolveIdentifier(DB::IdentifierLookup const&, DB::IdentifierResolveScope&, DB::IdentifierResolveContext) @ 0x00000000140298dd 6. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3692: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000001401a2b4 7. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3980: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000014018e31 8. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:4304: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000014042fa7 9. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5605: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000014013749 10. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3870: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x00000000140199de 11. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5334: DB::QueryAnalyzer::resolveQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&) @ 0x00000000140454b0 12. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5142: DB::QueryAnalyzer::resolveJoin(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&) @ 0x0000000014046de9 13. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5361: DB::QueryAnalyzer::resolveQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&) @ 0x00000000140452d6 14. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5597: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000140136f0 15. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000140127f9 16. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000014011fce 17. /build/src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000001406ce8a 18. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000014973b42 19. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000001497268d 20. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000014974d24 21. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001492924b 22. /build/src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88641 23. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 24. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 25. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 26. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 27. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 28. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 29. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 30. ? @ 0x00007fbc6213eac3 31. ? @ 0x00007fbc621d0850 2025.07.28 11:54:14.638494 [ 3283 ] {} TCPHandler: Code: 1. DB::Exception: Resolved identifier 'item_id' in parent scope to expression 'l.item_id' with correlated column 'item_id'. In scope SELECT item_id FROM t1. (UNSUPPORTED_METHOD), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/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 const&, String&&) @ 0x000000001404a1eb 4. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:1382: DB::QueryAnalyzer::tryResolveIdentifierInParentScopes(DB::IdentifierLookup const&, DB::IdentifierResolveScope&, DB::IdentifierResolveContext) @ 0x000000001402a8cc 5. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:1544: DB::QueryAnalyzer::tryResolveIdentifier(DB::IdentifierLookup const&, DB::IdentifierResolveScope&, DB::IdentifierResolveContext) @ 0x00000000140298dd 6. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3692: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000001401a2b4 7. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3980: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000014018e31 8. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:4304: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000014042fa7 9. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5605: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000014013749 10. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3870: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x00000000140199de 11. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5334: DB::QueryAnalyzer::resolveQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&) @ 0x00000000140454b0 12. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5142: DB::QueryAnalyzer::resolveJoin(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&) @ 0x0000000014046de9 13. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5361: DB::QueryAnalyzer::resolveQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&) @ 0x00000000140452d6 14. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5597: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000140136f0 15. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000140127f9 16. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000014011fce 17. /build/src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000001406ce8a 18. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000014973b42 19. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000001497268d 20. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000014974d24 21. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001492924b 22. /build/src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88641 23. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 24. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 25. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 26. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 27. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 28. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 29. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 30. ? @ 0x00007fbc6213eac3 31. ? @ 0x00007fbc621d0850 2025.07.28 11:54:14.645287 [ 3960 ] {} test_13.rmt2 (7f9b740d-015c-470e-8cc6-8ba33be0dc63): auto DB::StorageReplicatedMergeTree::processQueueEntry(ReplicatedMergeTreeQueue::SelectedEntryPtr)::(anonymous class)::operator()(LogEntryPtr &) const: Code: 86. DB::HTTPException: Received error from remote server http://146b4357c08d:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Ftest%2F01165%2Ftest_13%2Frmt%2Freplicas%2F1&part=20250728_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.6.10636.altinitytest (altinity build)) '. (RECEIVED_ERROR_FROM_REMOTE_IO_SERVER), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.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 const&, int&&, String const&, unsigned long&&, String const&) @ 0x000000000feda8d9 4. /build/src/IO/HTTPCommon.cpp:104: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x000000000feda6e2 5. /build/src/IO/HTTPCommon.cpp:93: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x000000000feda537 6. /build/src/IO/ReadWriteBufferFromHTTP.cpp:277: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x000000001184a4c4 7. /build/src/IO/ReadWriteBufferFromHTTP.cpp:285: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x000000001184a615 8. /build/src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x000000001184ae59 9. /build/src/IO/ReadWriteBufferFromHTTP.cpp:472: void std::__function::__policy_invoker::__call_impl[abi:se190107]>(std::__function::__policy_storage const*) @ 0x000000001184cedd 10. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001184858b 11. /build/src/IO/ReadWriteBufferFromHTTP.cpp:465: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x000000001184bf0b 12. /build/src/IO/ReadBuffer.h:60: DB::ReadBuffer::next() @ 0x000000000a148c7b 13. /build/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) @ 0x0000000011849fb2 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]>&)>&, 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&) @ 0x0000000011841980 15. /build/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) @ 0x000000001621208e 16. /build/src/Storages/StorageReplicatedMergeTree.cpp:5228: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl[abi:se190107] const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000015f9a5fe 17. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000015ed8bfd 18. /build/src/Storages/StorageReplicatedMergeTree.cpp:2514: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x0000000015ec9aab 19. /build/src/Storages/StorageReplicatedMergeTree.cpp:2349: DB::StorageReplicatedMergeTree::executeLogEntry(DB::ReplicatedMergeTreeLogEntry&) @ 0x0000000015eba91b 20. /build/src/Storages/StorageReplicatedMergeTree.cpp:3876: bool std::__function::__policy_invoker&)>::__call_impl[abi:se190107])::$_1, bool (std::shared_ptr&)>>(std::__function::__policy_storage const*, std::shared_ptr&) @ 0x0000000015f9837e 21. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000165d6fc3 22. /build/src/Storages/StorageReplicatedMergeTree.cpp:3872: DB::StorageReplicatedMergeTree::processQueueEntry(std::shared_ptr) @ 0x0000000015efc18a 23. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001624c1b2 24. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000162f9c70 25. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x00000000162fa55a 26. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc6653 27. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000000fccc4c3 28. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc3d92 29. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fcca080 30. ? @ 0x00007fbc6213eac3 31. ? @ 0x00007fbc621d0850 (version 25.3.6.10636.altinitytest (altinity build)) 2025.07.28 11:54:15.031674 [ 11826 ] {c3b2f098-0783-4988-a933-cbe4e3695e46} executeQuery: Code: 1. DB::Exception: Resolved identifier 'item_id' in parent scope to expression 'l.item_id' with correlated column 'item_id'. In scope SELECT item_id FROM t1 GROUP BY item_id. (UNSUPPORTED_METHOD) (version 25.3.6.10636.altinitytest (altinity build)) (from [::1]:45748) (comment: 03255_parallel_replicas_join_algo_and_analyzer_4.sh) (query 5, line 7) (in query: --SELECT '----- enable_parallel_replicas=0 prefer_local_plan=0 parallel_replicas_prefer_local_join=0 -----'; SELECT sum(item_id) FROM ( SELECT item_id FROM t ) AS l LEFT JOIN ( SELECT item_id FROM t1 GROUP BY item_id ) AS r ON l.item_id = r.item_id ;), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/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 const&, String&&) @ 0x000000001404a1eb 4. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:1382: DB::QueryAnalyzer::tryResolveIdentifierInParentScopes(DB::IdentifierLookup const&, DB::IdentifierResolveScope&, DB::IdentifierResolveContext) @ 0x000000001402a8cc 5. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:1544: DB::QueryAnalyzer::tryResolveIdentifier(DB::IdentifierLookup const&, DB::IdentifierResolveScope&, DB::IdentifierResolveContext) @ 0x00000000140298dd 6. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3692: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000001401a2b4 7. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3980: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000014018e31 8. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:4304: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000014042fa7 9. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5605: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000014013749 10. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3870: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x00000000140199de 11. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5334: DB::QueryAnalyzer::resolveQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&) @ 0x00000000140454b0 12. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5142: DB::QueryAnalyzer::resolveJoin(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&) @ 0x0000000014046de9 13. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5361: DB::QueryAnalyzer::resolveQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&) @ 0x00000000140452d6 14. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5597: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000140136f0 15. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000140127f9 16. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000014011fce 17. /build/src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000001406ce8a 18. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000014973b42 19. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000001497268d 20. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000014974d24 21. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001492924b 22. /build/src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88641 23. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 24. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 25. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 26. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 27. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 28. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 29. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 30. ? @ 0x00007fbc6213eac3 31. ? @ 0x00007fbc621d0850 2025.07.28 11:54:15.049055 [ 11826 ] {} TCPHandler: Code: 1. DB::Exception: Resolved identifier 'item_id' in parent scope to expression 'l.item_id' with correlated column 'item_id'. In scope SELECT item_id FROM t1 GROUP BY item_id. (UNSUPPORTED_METHOD), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/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 const&, String&&) @ 0x000000001404a1eb 4. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:1382: DB::QueryAnalyzer::tryResolveIdentifierInParentScopes(DB::IdentifierLookup const&, DB::IdentifierResolveScope&, DB::IdentifierResolveContext) @ 0x000000001402a8cc 5. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:1544: DB::QueryAnalyzer::tryResolveIdentifier(DB::IdentifierLookup const&, DB::IdentifierResolveScope&, DB::IdentifierResolveContext) @ 0x00000000140298dd 6. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3692: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000001401a2b4 7. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3980: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000014018e31 8. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:4304: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000014042fa7 9. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5605: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000014013749 10. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3870: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x00000000140199de 11. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5334: DB::QueryAnalyzer::resolveQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&) @ 0x00000000140454b0 12. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5142: DB::QueryAnalyzer::resolveJoin(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&) @ 0x0000000014046de9 13. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5361: DB::QueryAnalyzer::resolveQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&) @ 0x00000000140452d6 14. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5597: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000140136f0 15. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000140127f9 16. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000014011fce 17. /build/src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000001406ce8a 18. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000014973b42 19. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000001497268d 20. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000014974d24 21. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001492924b 22. /build/src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88641 23. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 24. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 25. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 26. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 27. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 28. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 29. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 30. ? @ 0x00007fbc6213eac3 31. ? @ 0x00007fbc621d0850 2025.07.28 11:54:15.130227 [ 7409 ] {} ExternalDictionariesLoader: Could not load external dictionary 'cc8b1a52-da70-449c-9c23-8d623c5fcc44', next update is scheduled at 2025-07-28 11:54:32: Code: 396. DB::Exception: Limit for result exceeded, max bytes: 1.00 B, current bytes: 36.00 B. (TOO_MANY_ROWS_OR_BYTES), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, char const*&, ReadableSize&&, ReadableSize&&) @ 0x0000000013bd4eeb 4. /build/src/QueryPipeline/SizeLimits.cpp:43: DB::SizeLimits::check(unsigned long, unsigned long, char const*, int, int) const @ 0x0000000013bd48a1 5. /build/src/Processors/Transforms/LimitsCheckingTransform.cpp:45: DB::LimitsCheckingTransform::transform(DB::Chunk&) @ 0x0000000016c1d2fb 6. /build/src/Processors/ISimpleTransform.h:33: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000011a9a453 7. /build/src/Processors/ISimpleTransform.cpp:89: DB::ISimpleTransform::work() @ 0x000000001699fca0 8. /build/src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x00000000169bd00f 9. /build/src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x00000000169b2105 10. /build/src/Processors/Executors/PipelineExecutor.cpp:170: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x00000000169b16a7 11. /build/src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x00000000169c081c 12. /build/src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x00000000169c0978 13. /build/src/Dictionaries/FlatDictionary.cpp:502: DB::FlatDictionary::loadData() @ 0x0000000011b424cb 14. /build/src/Dictionaries/FlatDictionary.cpp:46: DB::FlatDictionary::FlatDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, DB::FlatDictionary::Configuration, std::shared_ptr) @ 0x0000000011b42111 15. /build/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:se190107]> (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) @ 0x0000000011b5d3e2 16. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000012d8a61d 17. /build/src/Interpreters/ExternalDictionariesLoader.cpp:47: DB::ExternalDictionariesLoader::createObject(String const&, Poco::Util::AbstractConfiguration const&, String const&, String const&) const @ 0x00000000148a6f44 18. /build/src/Interpreters/ExternalLoader.cpp:1522: DB::ExternalLoader::LoadingDispatcher::loadSingleObject(String const&, DB::ExternalLoader::ObjectConfig const&, std::shared_ptr) @ 0x00000000148b2ee8 19. /build/src/Interpreters/ExternalLoader.cpp:998: DB::ExternalLoader::LoadingDispatcher::doLoading(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr) @ 0x00000000148b197d 20. /build/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()() @ 0x00000000148b5991 21. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc3d92 22. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fcca080 23. ? @ 0x00007fbc6213eac3 24. ? @ 0x00007fbc621d0850 (version 25.3.6.10636.altinitytest (altinity build)) 2025.07.28 11:54:15.316003 [ 17557 ] {630cd64a-a7a1-4b63-8a5a-a3f4211af0a7} executeQuery: Code: 43. DB::Exception: A value of illegal type was provided as 2nd argument 'size' to function 'arrayResize'. Expected: Number, got: Nullable(UInt8): In scope SELECT arrayResize([1, 2, 3], toNullable(3)). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.6.10636.altinitytest (altinity build)) (from [::1]:45652) (comment: 00557_array_resize.sql) (query 15, line 18) (in query: -- Second argument cannot be Nullable select arrayResize([1, 2, 3], toNullable(3));), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: 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&&) @ 0x0000000012da74d9 4. /build/src/Functions/FunctionHelpers.cpp:130: DB::(anonymous namespace)::validateArgumentsImpl(DB::IFunction const&, std::vector> const&, unsigned long, std::vector> const&) @ 0x0000000012da5b15 5. /build/src/Functions/FunctionHelpers.cpp:192: DB::validateFunctionArguments(DB::IFunction const&, std::vector> const&, std::vector> const&, std::vector> const&) @ 0x0000000012da54fb 6. /build/src/Functions/array/arrayResize.cpp:36: DB::FunctionArrayResize::getReturnTypeImpl(std::vector> const&) const @ 0x00000000142d85b9 7. /build/src/Functions/IFunction.cpp:645: DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x0000000012d96b0c 8. /build/src/Functions/IFunction.cpp:577: DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x0000000012d9669c 9. /build/src/Functions/IFunction.cpp:606: DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x0000000012d96edc 10. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3544: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000014033cc9 11. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3838: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000014019a9e 12. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3980: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000014018e31 13. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:4304: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000014042fa7 14. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5605: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000014013749 15. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000140127f9 16. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000014011fce 17. /build/src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000001406ce8a 18. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000014973b42 19. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000001497268d 20. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000014974d24 21. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001492924b 22. /build/src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88641 23. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 24. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 25. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 26. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 27. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 28. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 29. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 30. ? @ 0x00007fbc6213eac3 31. ? @ 0x00007fbc621d0850 2025.07.28 11:54:15.327497 [ 17270 ] {1fe9508c-ae20-4c12-8832-c465567bd50f} executeQuery: Code: 69. DB::Exception: The number of shift positions needs to be a non-negative value: In scope SELECT bitShiftRight(1, -1). (ARGUMENT_OUT_OF_BOUND) (version 25.3.6.10636.altinitytest (altinity build)) (from [::1]:45758) (comment: 03198_bit_shift_throws_error_for_out_of_bounds.sql) (query 2, line 2) (in query: SELECT bitShiftRight(1, -1);), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000000a074fcb 4. /build/src/Functions/bitShiftRight.cpp:30: DB::(anonymous namespace)::BitShiftRightImpl DB::(anonymous namespace)::BitShiftRightImpl::apply>(char8_t, DB::(anonymous namespace)::BitShiftRightImpl) @ 0x000000000b020408 5. /build/src/Functions/FunctionBinaryArithmetic.h:309: _ZN2DBL16castTypeToEitherIJNS_14DataTypeNumberIDuEENS1_ItEENS1_IjEENS1_ImEENS1_IN4wide7integerILm128EjEEEENS1_INS7_ILm256EjEEEENS1_IDB8_EENS1_IsEENS1_IiEENS1_IlEENS1_INS7_ILm128EiEEEENS1_INS7_ILm256EiEEEENS_15DataTypeDecimalINS_7DecimalIiEEEENSL_INSM_IlEEEENSL_INSM_ISH_EEEENSL_INSM_ISJ_EEEENS_12DataTypeDateENS_16DataTypeDateTimeENS_19DataTypeFixedStringENS_14DataTypeStringENS_16DataTypeIntervalEENS_9IDataTypeEZZNS_24FunctionBinaryArithmeticINS_12_GLOBAL__N_117BitShiftRightImplENS12_17NameBitShiftRightELb1ELb0ELb0EE13castBothTypesIZNKS15_12executeImpl2ERKNSt3__16vectorINS_21ColumnWithTypeAndNameENS17_9allocatorIS19_EEEERKNS17_10shared_ptrIKS10_EEmPKNS_8PODArrayIDuLm4096E9AllocatorILb0ELb0EELm63ELm64EEEEUlRKT_RKT0_E_EEbPS1G_S1X_OS1Q_ENKUlS1S_E_clIS2_EEDaS1S_EUlS1S_E_EEb8TypeListIJDpT_EEPS1U_OT1_ @ 0x000000000b066e4a 6. /build/src/Functions/FunctionBinaryArithmetic.h:838: DB::FunctionBinaryArithmetic::executeImpl2(std::vector> const&, std::shared_ptr const&, unsigned long, DB::PODArray, 63ul, 64ul> const*) const @ 0x000000000b05dd5c 7. /build/src/Functions/FunctionBinaryArithmetic.h:2410: DB::FunctionBinaryArithmetic::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000b05c7d7 8. /build/src/Functions/FunctionBinaryArithmetic.h:2645: DB::FunctionBinaryArithmeticWithConstants::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000b05b6f4 9. /build/src/Functions/IFunction.h:437: DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000a069f2a 10. /build/src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000012d9965a 11. /build/src/Functions/IFunction.cpp:351: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d93b02 12. /build/src/Functions/IFunction.cpp:420: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d95059 13. /build/src/Functions/IFunction.cpp:498: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d95c72 14. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3567: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000014034494 15. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3838: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000014019a9e 16. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3980: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000014018e31 17. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:4304: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000014042fa7 18. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5605: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000014013749 19. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000140127f9 20. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000014011fce 21. /build/src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000001406ce8a 22. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000014973b42 23. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000001497268d 24. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000014974d24 25. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001492924b 26. /build/src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88641 27. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 28. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 29. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 30. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 31. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 2025.07.28 11:54:15.347962 [ 17557 ] {} TCPHandler: Code: 43. DB::Exception: A value of illegal type was provided as 2nd argument 'size' to function 'arrayResize'. Expected: Number, got: Nullable(UInt8): In scope SELECT arrayResize([1, 2, 3], toNullable(3)). (ILLEGAL_TYPE_OF_ARGUMENT), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: 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&&) @ 0x0000000012da74d9 4. /build/src/Functions/FunctionHelpers.cpp:130: DB::(anonymous namespace)::validateArgumentsImpl(DB::IFunction const&, std::vector> const&, unsigned long, std::vector> const&) @ 0x0000000012da5b15 5. /build/src/Functions/FunctionHelpers.cpp:192: DB::validateFunctionArguments(DB::IFunction const&, std::vector> const&, std::vector> const&, std::vector> const&) @ 0x0000000012da54fb 6. /build/src/Functions/array/arrayResize.cpp:36: DB::FunctionArrayResize::getReturnTypeImpl(std::vector> const&) const @ 0x00000000142d85b9 7. /build/src/Functions/IFunction.cpp:645: DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x0000000012d96b0c 8. /build/src/Functions/IFunction.cpp:577: DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x0000000012d9669c 9. /build/src/Functions/IFunction.cpp:606: DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x0000000012d96edc 10. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3544: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000014033cc9 11. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3838: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000014019a9e 12. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3980: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000014018e31 13. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:4304: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000014042fa7 14. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5605: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000014013749 15. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000140127f9 16. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000014011fce 17. /build/src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000001406ce8a 18. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000014973b42 19. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000001497268d 20. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000014974d24 21. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001492924b 22. /build/src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88641 23. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 24. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 25. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 26. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 27. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 28. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 29. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 30. ? @ 0x00007fbc6213eac3 31. ? @ 0x00007fbc621d0850 2025.07.28 11:54:15.356781 [ 17270 ] {} TCPHandler: Code: 69. DB::Exception: The number of shift positions needs to be a non-negative value: In scope SELECT bitShiftRight(1, -1). (ARGUMENT_OUT_OF_BOUND), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000000a074fcb 4. /build/src/Functions/bitShiftRight.cpp:30: DB::(anonymous namespace)::BitShiftRightImpl DB::(anonymous namespace)::BitShiftRightImpl::apply>(char8_t, DB::(anonymous namespace)::BitShiftRightImpl) @ 0x000000000b020408 5. /build/src/Functions/FunctionBinaryArithmetic.h:309: _ZN2DBL16castTypeToEitherIJNS_14DataTypeNumberIDuEENS1_ItEENS1_IjEENS1_ImEENS1_IN4wide7integerILm128EjEEEENS1_INS7_ILm256EjEEEENS1_IDB8_EENS1_IsEENS1_IiEENS1_IlEENS1_INS7_ILm128EiEEEENS1_INS7_ILm256EiEEEENS_15DataTypeDecimalINS_7DecimalIiEEEENSL_INSM_IlEEEENSL_INSM_ISH_EEEENSL_INSM_ISJ_EEEENS_12DataTypeDateENS_16DataTypeDateTimeENS_19DataTypeFixedStringENS_14DataTypeStringENS_16DataTypeIntervalEENS_9IDataTypeEZZNS_24FunctionBinaryArithmeticINS_12_GLOBAL__N_117BitShiftRightImplENS12_17NameBitShiftRightELb1ELb0ELb0EE13castBothTypesIZNKS15_12executeImpl2ERKNSt3__16vectorINS_21ColumnWithTypeAndNameENS17_9allocatorIS19_EEEERKNS17_10shared_ptrIKS10_EEmPKNS_8PODArrayIDuLm4096E9AllocatorILb0ELb0EELm63ELm64EEEEUlRKT_RKT0_E_EEbPS1G_S1X_OS1Q_ENKUlS1S_E_clIS2_EEDaS1S_EUlS1S_E_EEb8TypeListIJDpT_EEPS1U_OT1_ @ 0x000000000b066e4a 6. /build/src/Functions/FunctionBinaryArithmetic.h:838: DB::FunctionBinaryArithmetic::executeImpl2(std::vector> const&, std::shared_ptr const&, unsigned long, DB::PODArray, 63ul, 64ul> const*) const @ 0x000000000b05dd5c 7. /build/src/Functions/FunctionBinaryArithmetic.h:2410: DB::FunctionBinaryArithmetic::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000b05c7d7 8. /build/src/Functions/FunctionBinaryArithmetic.h:2645: DB::FunctionBinaryArithmeticWithConstants::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000b05b6f4 9. /build/src/Functions/IFunction.h:437: DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000a069f2a 10. /build/src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000012d9965a 11. /build/src/Functions/IFunction.cpp:351: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d93b02 12. /build/src/Functions/IFunction.cpp:420: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d95059 13. /build/src/Functions/IFunction.cpp:498: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d95c72 14. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3567: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000014034494 15. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3838: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000014019a9e 16. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3980: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000014018e31 17. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:4304: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000014042fa7 18. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5605: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000014013749 19. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000140127f9 20. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000014011fce 21. /build/src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000001406ce8a 22. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000014973b42 23. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000001497268d 24. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000014974d24 25. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001492924b 26. /build/src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88641 27. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 28. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 29. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 30. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 31. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 2025.07.28 11:54:15.381551 [ 3972 ] {} test_13.rmt2 (7f9b740d-015c-470e-8cc6-8ba33be0dc63): auto DB::StorageReplicatedMergeTree::processQueueEntry(ReplicatedMergeTreeQueue::SelectedEntryPtr)::(anonymous class)::operator()(LogEntryPtr &) const: Code: 86. DB::HTTPException: Received error from remote server http://146b4357c08d:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Ftest%2F01165%2Ftest_13%2Frmt%2Freplicas%2F1&part=20250728_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.6.10636.altinitytest (altinity build)) '. (RECEIVED_ERROR_FROM_REMOTE_IO_SERVER), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.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 const&, int&&, String const&, unsigned long&&, String const&) @ 0x000000000feda8d9 4. /build/src/IO/HTTPCommon.cpp:104: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x000000000feda6e2 5. /build/src/IO/HTTPCommon.cpp:93: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x000000000feda537 6. /build/src/IO/ReadWriteBufferFromHTTP.cpp:277: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x000000001184a4c4 7. /build/src/IO/ReadWriteBufferFromHTTP.cpp:285: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x000000001184a615 8. /build/src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x000000001184ae59 9. /build/src/IO/ReadWriteBufferFromHTTP.cpp:472: void std::__function::__policy_invoker::__call_impl[abi:se190107]>(std::__function::__policy_storage const*) @ 0x000000001184cedd 10. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001184858b 11. /build/src/IO/ReadWriteBufferFromHTTP.cpp:465: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x000000001184bf0b 12. /build/src/IO/ReadBuffer.h:60: DB::ReadBuffer::next() @ 0x000000000a148c7b 13. /build/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) @ 0x0000000011849fb2 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]>&)>&, 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&) @ 0x0000000011841980 15. /build/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) @ 0x000000001621208e 16. /build/src/Storages/StorageReplicatedMergeTree.cpp:5228: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl[abi:se190107] const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000015f9a5fe 17. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000015ed8bfd 18. /build/src/Storages/StorageReplicatedMergeTree.cpp:2514: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x0000000015ec9aab 19. /build/src/Storages/StorageReplicatedMergeTree.cpp:2349: DB::StorageReplicatedMergeTree::executeLogEntry(DB::ReplicatedMergeTreeLogEntry&) @ 0x0000000015eba91b 20. /build/src/Storages/StorageReplicatedMergeTree.cpp:3876: bool std::__function::__policy_invoker&)>::__call_impl[abi:se190107])::$_1, bool (std::shared_ptr&)>>(std::__function::__policy_storage const*, std::shared_ptr&) @ 0x0000000015f9837e 21. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000165d6fc3 22. /build/src/Storages/StorageReplicatedMergeTree.cpp:3872: DB::StorageReplicatedMergeTree::processQueueEntry(std::shared_ptr) @ 0x0000000015efc18a 23. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001624c1b2 24. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000162f9c70 25. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x00000000162fa55a 26. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc6653 27. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000000fccc4c3 28. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc3d92 29. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fcca080 30. ? @ 0x00007fbc6213eac3 31. ? @ 0x00007fbc621d0850 (version 25.3.6.10636.altinitytest (altinity build)) 2025.07.28 11:54:15.410808 [ 17557 ] {afa1a397-2f33-4f4b-a2ac-d4668319ac67} executeQuery: Code: 43. DB::Exception: A value of illegal type was provided as 2nd argument 'size' to function 'arrayResize'. Expected: Number, got: Nullable(UInt8): In scope SELECT arrayResize(materialize([1]), toNullable(3)). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.6.10636.altinitytest (altinity build)) (from [::1]:45652) (comment: 00557_array_resize.sql) (query 16, line 20) (in query: SELECT arrayResize(materialize([1]), toNullable(3)) -- { serverError ILLEGAL_TYPE_OF_ARGUMENT } ), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: 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&&) @ 0x0000000012da74d9 4. /build/src/Functions/FunctionHelpers.cpp:130: DB::(anonymous namespace)::validateArgumentsImpl(DB::IFunction const&, std::vector> const&, unsigned long, std::vector> const&) @ 0x0000000012da5b15 5. /build/src/Functions/FunctionHelpers.cpp:192: DB::validateFunctionArguments(DB::IFunction const&, std::vector> const&, std::vector> const&, std::vector> const&) @ 0x0000000012da54fb 6. /build/src/Functions/array/arrayResize.cpp:36: DB::FunctionArrayResize::getReturnTypeImpl(std::vector> const&) const @ 0x00000000142d85b9 7. /build/src/Functions/IFunction.cpp:645: DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x0000000012d96b0c 8. /build/src/Functions/IFunction.cpp:577: DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x0000000012d9669c 9. /build/src/Functions/IFunction.cpp:606: DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x0000000012d96edc 10. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3544: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000014033cc9 11. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3838: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000014019a9e 12. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3980: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000014018e31 13. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:4304: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000014042fa7 14. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5605: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000014013749 15. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000140127f9 16. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000014011fce 17. /build/src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000001406ce8a 18. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000014973b42 19. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000001497268d 20. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000014974d24 21. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001492924b 22. /build/src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88641 23. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 24. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 25. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 26. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 27. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 28. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 29. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 30. ? @ 0x00007fbc6213eac3 31. ? @ 0x00007fbc621d0850 2025.07.28 11:54:15.411276 [ 11826 ] {702a704b-a973-439a-8c0a-ea09ddedc6c3} executeQuery: Code: 1. DB::Exception: Resolved identifier 'item_id' in parent scope to expression 'l.item_id' with correlated column 'item_id'. In scope SELECT item_id FROM t1 GROUP BY item_id. (UNSUPPORTED_METHOD) (version 25.3.6.10636.altinitytest (altinity build)) (from [::1]:45784) (comment: 03255_parallel_replicas_join_algo_and_analyzer_4.sh) (query 5, line 7) (in query: --SELECT '----- enable_parallel_replicas=1 prefer_local_plan=0 parallel_replicas_prefer_local_join=0 -----'; SELECT sum(item_id) FROM ( SELECT item_id FROM t ) AS l LEFT JOIN ( SELECT item_id FROM t1 GROUP BY item_id ) AS r ON l.item_id = r.item_id ;), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/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 const&, String&&) @ 0x000000001404a1eb 4. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:1382: DB::QueryAnalyzer::tryResolveIdentifierInParentScopes(DB::IdentifierLookup const&, DB::IdentifierResolveScope&, DB::IdentifierResolveContext) @ 0x000000001402a8cc 5. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:1544: DB::QueryAnalyzer::tryResolveIdentifier(DB::IdentifierLookup const&, DB::IdentifierResolveScope&, DB::IdentifierResolveContext) @ 0x00000000140298dd 6. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3692: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000001401a2b4 7. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3980: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000014018e31 8. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:4304: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000014042fa7 9. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5605: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000014013749 10. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3870: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x00000000140199de 11. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5334: DB::QueryAnalyzer::resolveQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&) @ 0x00000000140454b0 12. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5142: DB::QueryAnalyzer::resolveJoin(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&) @ 0x0000000014046de9 13. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5361: DB::QueryAnalyzer::resolveQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&) @ 0x00000000140452d6 14. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5597: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000140136f0 15. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000140127f9 16. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000014011fce 17. /build/src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000001406ce8a 18. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000014973b42 19. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000001497268d 20. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000014974d24 21. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001492924b 22. /build/src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88641 23. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 24. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 25. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 26. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 27. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 28. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 29. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 30. ? @ 0x00007fbc6213eac3 31. ? @ 0x00007fbc621d0850 2025.07.28 11:54:15.415621 [ 17557 ] {} TCPHandler: Code: 43. DB::Exception: A value of illegal type was provided as 2nd argument 'size' to function 'arrayResize'. Expected: Number, got: Nullable(UInt8): In scope SELECT arrayResize(materialize([1]), toNullable(3)). (ILLEGAL_TYPE_OF_ARGUMENT), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: 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&&) @ 0x0000000012da74d9 4. /build/src/Functions/FunctionHelpers.cpp:130: DB::(anonymous namespace)::validateArgumentsImpl(DB::IFunction const&, std::vector> const&, unsigned long, std::vector> const&) @ 0x0000000012da5b15 5. /build/src/Functions/FunctionHelpers.cpp:192: DB::validateFunctionArguments(DB::IFunction const&, std::vector> const&, std::vector> const&, std::vector> const&) @ 0x0000000012da54fb 6. /build/src/Functions/array/arrayResize.cpp:36: DB::FunctionArrayResize::getReturnTypeImpl(std::vector> const&) const @ 0x00000000142d85b9 7. /build/src/Functions/IFunction.cpp:645: DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x0000000012d96b0c 8. /build/src/Functions/IFunction.cpp:577: DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x0000000012d9669c 9. /build/src/Functions/IFunction.cpp:606: DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x0000000012d96edc 10. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3544: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000014033cc9 11. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3838: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000014019a9e 12. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3980: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000014018e31 13. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:4304: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000014042fa7 14. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5605: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000014013749 15. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000140127f9 16. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000014011fce 17. /build/src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000001406ce8a 18. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000014973b42 19. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000001497268d 20. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000014974d24 21. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001492924b 22. /build/src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88641 23. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 24. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 25. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 26. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 27. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 28. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 29. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 30. ? @ 0x00007fbc6213eac3 31. ? @ 0x00007fbc621d0850 2025.07.28 11:54:15.450175 [ 11826 ] {} TCPHandler: Code: 1. DB::Exception: Resolved identifier 'item_id' in parent scope to expression 'l.item_id' with correlated column 'item_id'. In scope SELECT item_id FROM t1 GROUP BY item_id. (UNSUPPORTED_METHOD), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/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 const&, String&&) @ 0x000000001404a1eb 4. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:1382: DB::QueryAnalyzer::tryResolveIdentifierInParentScopes(DB::IdentifierLookup const&, DB::IdentifierResolveScope&, DB::IdentifierResolveContext) @ 0x000000001402a8cc 5. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:1544: DB::QueryAnalyzer::tryResolveIdentifier(DB::IdentifierLookup const&, DB::IdentifierResolveScope&, DB::IdentifierResolveContext) @ 0x00000000140298dd 6. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3692: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000001401a2b4 7. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3980: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000014018e31 8. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:4304: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000014042fa7 9. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5605: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000014013749 10. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3870: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x00000000140199de 11. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5334: DB::QueryAnalyzer::resolveQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&) @ 0x00000000140454b0 12. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5142: DB::QueryAnalyzer::resolveJoin(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&) @ 0x0000000014046de9 13. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5361: DB::QueryAnalyzer::resolveQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&) @ 0x00000000140452d6 14. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5597: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000140136f0 15. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000140127f9 16. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000014011fce 17. /build/src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000001406ce8a 18. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000014973b42 19. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000001497268d 20. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000014974d24 21. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001492924b 22. /build/src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88641 23. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 24. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 25. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 26. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 27. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 28. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 29. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 30. ? @ 0x00007fbc6213eac3 31. ? @ 0x00007fbc621d0850 2025.07.28 11:54:15.615739 [ 17270 ] {98514691-ce03-4432-85c8-e0492fc457cb} executeQuery: Code: 69. DB::Exception: The number of shift positions needs to be a non-negative value: In scope SELECT bitShiftRight('hola', -1). (ARGUMENT_OUT_OF_BOUND) (version 25.3.6.10636.altinitytest (altinity build)) (from [::1]:45758) (comment: 03198_bit_shift_throws_error_for_out_of_bounds.sql) (query 4, line 4) (in query: SELECT bitShiftRight('hola', -1);), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000000a074fcb 4. /build/src/Functions/bitShiftRight.cpp:65: void DB::impl_::StringIntegerOperationImpl<_BitInt(8), DB::(anonymous namespace)::BitShiftRightImpl>::processString<(DB::impl_::OpCase)0>(char8_t const*, unsigned long const*, DB::(anonymous namespace) const*, DB::PODArray, 63ul, 64ul>&, Allocator, 63ul, 64ul>, 63ul, 64ul>&, unsigned long) @ 0x000000000b04c2f0 5. /build/src/Functions/FunctionBinaryArithmetic.h:2154: _ZN2DBL16castTypeToEitherIJNS_14DataTypeNumberIDuEENS1_ItEENS1_IjEENS1_ImEENS1_IN4wide7integerILm128EjEEEENS1_INS7_ILm256EjEEEENS1_IDB8_EENS1_IsEENS1_IiEENS1_IlEENS1_INS7_ILm128EiEEEENS1_INS7_ILm256EiEEEENS_15DataTypeDecimalINS_7DecimalIiEEEENSL_INSM_IlEEEENSL_INSM_ISH_EEEENSL_INSM_ISJ_EEEENS_12DataTypeDateENS_16DataTypeDateTimeENS_19DataTypeFixedStringENS_14DataTypeStringENS_16DataTypeIntervalEENS_9IDataTypeEZZNS_24FunctionBinaryArithmeticINS_12_GLOBAL__N_117BitShiftRightImplENS12_17NameBitShiftRightELb1ELb0ELb0EE13castBothTypesIZNKS15_12executeImpl2ERKNSt3__16vectorINS_21ColumnWithTypeAndNameENS17_9allocatorIS19_EEEERKNS17_10shared_ptrIKS10_EEmPKNS_8PODArrayIDuLm4096E9AllocatorILb0ELb0EELm63ELm64EEEEUlRKT_RKT0_E_EEbPS1G_S1X_OS1Q_ENKUlS1S_E_clISY_EEDaS1S_EUlS1S_E_EEb8TypeListIJDpT_EEPS1U_OT1_ @ 0x000000000b0aedf8 6. /build/src/Functions/FunctionBinaryArithmetic.h:838: DB::FunctionBinaryArithmetic::executeImpl2(std::vector> const&, std::shared_ptr const&, unsigned long, DB::PODArray, 63ul, 64ul> const*) const @ 0x000000000b05e515 7. /build/src/Functions/FunctionBinaryArithmetic.h:2410: DB::FunctionBinaryArithmetic::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000b05c7d7 8. /build/src/Functions/FunctionBinaryArithmetic.h:2645: DB::FunctionBinaryArithmeticWithConstants::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000b05b6f4 9. /build/src/Functions/IFunction.h:437: DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000a069f2a 10. /build/src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000012d9965a 11. /build/src/Functions/IFunction.cpp:351: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d93b02 12. /build/src/Functions/IFunction.cpp:420: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d95059 13. /build/src/Functions/IFunction.cpp:498: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d95c72 14. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3567: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000014034494 15. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3838: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000014019a9e 16. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3980: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000014018e31 17. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:4304: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000014042fa7 18. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5605: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000014013749 19. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000140127f9 20. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000014011fce 21. /build/src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000001406ce8a 22. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000014973b42 23. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000001497268d 24. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000014974d24 25. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001492924b 26. /build/src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88641 27. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 28. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 29. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 30. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 31. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 2025.07.28 11:54:15.621146 [ 17270 ] {} TCPHandler: Code: 69. DB::Exception: The number of shift positions needs to be a non-negative value: In scope SELECT bitShiftRight('hola', -1). (ARGUMENT_OUT_OF_BOUND), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000000a074fcb 4. /build/src/Functions/bitShiftRight.cpp:65: void DB::impl_::StringIntegerOperationImpl<_BitInt(8), DB::(anonymous namespace)::BitShiftRightImpl>::processString<(DB::impl_::OpCase)0>(char8_t const*, unsigned long const*, DB::(anonymous namespace) const*, DB::PODArray, 63ul, 64ul>&, Allocator, 63ul, 64ul>, 63ul, 64ul>&, unsigned long) @ 0x000000000b04c2f0 5. /build/src/Functions/FunctionBinaryArithmetic.h:2154: _ZN2DBL16castTypeToEitherIJNS_14DataTypeNumberIDuEENS1_ItEENS1_IjEENS1_ImEENS1_IN4wide7integerILm128EjEEEENS1_INS7_ILm256EjEEEENS1_IDB8_EENS1_IsEENS1_IiEENS1_IlEENS1_INS7_ILm128EiEEEENS1_INS7_ILm256EiEEEENS_15DataTypeDecimalINS_7DecimalIiEEEENSL_INSM_IlEEEENSL_INSM_ISH_EEEENSL_INSM_ISJ_EEEENS_12DataTypeDateENS_16DataTypeDateTimeENS_19DataTypeFixedStringENS_14DataTypeStringENS_16DataTypeIntervalEENS_9IDataTypeEZZNS_24FunctionBinaryArithmeticINS_12_GLOBAL__N_117BitShiftRightImplENS12_17NameBitShiftRightELb1ELb0ELb0EE13castBothTypesIZNKS15_12executeImpl2ERKNSt3__16vectorINS_21ColumnWithTypeAndNameENS17_9allocatorIS19_EEEERKNS17_10shared_ptrIKS10_EEmPKNS_8PODArrayIDuLm4096E9AllocatorILb0ELb0EELm63ELm64EEEEUlRKT_RKT0_E_EEbPS1G_S1X_OS1Q_ENKUlS1S_E_clISY_EEDaS1S_EUlS1S_E_EEb8TypeListIJDpT_EEPS1U_OT1_ @ 0x000000000b0aedf8 6. /build/src/Functions/FunctionBinaryArithmetic.h:838: DB::FunctionBinaryArithmetic::executeImpl2(std::vector> const&, std::shared_ptr const&, unsigned long, DB::PODArray, 63ul, 64ul> const*) const @ 0x000000000b05e515 7. /build/src/Functions/FunctionBinaryArithmetic.h:2410: DB::FunctionBinaryArithmetic::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000b05c7d7 8. /build/src/Functions/FunctionBinaryArithmetic.h:2645: DB::FunctionBinaryArithmeticWithConstants::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000b05b6f4 9. /build/src/Functions/IFunction.h:437: DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000a069f2a 10. /build/src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000012d9965a 11. /build/src/Functions/IFunction.cpp:351: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d93b02 12. /build/src/Functions/IFunction.cpp:420: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d95059 13. /build/src/Functions/IFunction.cpp:498: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d95c72 14. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3567: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000014034494 15. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3838: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000014019a9e 16. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3980: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000014018e31 17. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:4304: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000014042fa7 18. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5605: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000014013749 19. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000140127f9 20. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000014011fce 21. /build/src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000001406ce8a 22. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000014973b42 23. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000001497268d 24. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000014974d24 25. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001492924b 26. /build/src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88641 27. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 28. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 29. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 30. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 31. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 2025.07.28 11:54:15.636396 [ 11826 ] {0b50bc48-2e09-4a53-b9f0-dc54b63027cb} executeQuery: Code: 57. DB::Exception: Table test_1.bloom_filter_idx already exists. (TABLE_ALREADY_EXISTS) (version 25.3.6.10636.altinitytest (altinity build)) (from [::1]:45806) (comment: 00944_create_bloom_filter_index_with_merge_tree.sh) (query 1, line 1) (in query: CREATE TABLE bloom_filter_idx (`u64` UInt64, `i32` Int32, `f64` Float64, `d` Decimal(10, 2), `s` String, `e` Enum8('a' = 1, 'b' = 2, 'c' = 3), `dt` Date, INDEX bloom_filter_a i32 TYPE bloom_filter(0.0001) GRANULARITY 1) ENGINE = MergeTree ORDER BY u64 SETTINGS index_granularity = 8192, 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 = 0, compact_parts_max_bytes_to_buffer = 526286706, compact_parts_max_granules_to_buffer = 99, compact_parts_merge_max_bytes_to_prefetch_part = 30629771, merge_max_block_size = 11376, old_parts_lifetime = 22., 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 = 6192558, use_const_adaptive_granularity = true, enable_index_granularity_compression = true, concurrent_part_removal_threshold = 100, allow_vertical_merges_from_compact_to_wide_parts = true, enable_block_number_column = true, enable_block_offset_column = true, cache_populated_by_fetch = false, marks_compress_block_size = 13299, primary_key_compress_block_size = 13718, 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. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000a06a8eb 4. /build/src/Interpreters/InterpreterCreateQuery.cpp:1824: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x0000000014901d53 5. /build/src/Interpreters/InterpreterCreateQuery.cpp:1743: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000148f9aa9 6. /build/src/Interpreters/InterpreterCreateQuery.cpp:2352: DB::InterpreterCreateQuery::execute() @ 0x0000000014905a41 7. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88dc9 8. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 9. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 10. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 11. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 12. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 13. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 14. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 15. ? @ 0x00007fbc6213eac3 16. ? @ 0x00007fbc621d0850 2025.07.28 11:54:15.660469 [ 11826 ] {} TCPHandler: Code: 57. DB::Exception: Table test_1.bloom_filter_idx already exists. (TABLE_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000a06a8eb 4. /build/src/Interpreters/InterpreterCreateQuery.cpp:1824: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x0000000014901d53 5. /build/src/Interpreters/InterpreterCreateQuery.cpp:1743: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000148f9aa9 6. /build/src/Interpreters/InterpreterCreateQuery.cpp:2352: DB::InterpreterCreateQuery::execute() @ 0x0000000014905a41 7. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88dc9 8. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 9. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 10. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 11. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 12. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 13. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 14. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 15. ? @ 0x00007fbc6213eac3 16. ? @ 0x00007fbc621d0850 2025.07.28 11:54:15.862925 [ 3965 ] {} test_13.rmt2 (7f9b740d-015c-470e-8cc6-8ba33be0dc63): auto DB::StorageReplicatedMergeTree::processQueueEntry(ReplicatedMergeTreeQueue::SelectedEntryPtr)::(anonymous class)::operator()(LogEntryPtr &) const: Code: 86. DB::HTTPException: Received error from remote server http://146b4357c08d:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Ftest%2F01165%2Ftest_13%2Frmt%2Freplicas%2F1&part=20250728_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.6.10636.altinitytest (altinity build)) '. (RECEIVED_ERROR_FROM_REMOTE_IO_SERVER), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.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 const&, int&&, String const&, unsigned long&&, String const&) @ 0x000000000feda8d9 4. /build/src/IO/HTTPCommon.cpp:104: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x000000000feda6e2 5. /build/src/IO/HTTPCommon.cpp:93: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x000000000feda537 6. /build/src/IO/ReadWriteBufferFromHTTP.cpp:277: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x000000001184a4c4 7. /build/src/IO/ReadWriteBufferFromHTTP.cpp:285: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x000000001184a615 8. /build/src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x000000001184ae59 9. /build/src/IO/ReadWriteBufferFromHTTP.cpp:472: void std::__function::__policy_invoker::__call_impl[abi:se190107]>(std::__function::__policy_storage const*) @ 0x000000001184cedd 10. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001184858b 11. /build/src/IO/ReadWriteBufferFromHTTP.cpp:465: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x000000001184bf0b 12. /build/src/IO/ReadBuffer.h:60: DB::ReadBuffer::next() @ 0x000000000a148c7b 13. /build/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) @ 0x0000000011849fb2 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]>&)>&, 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&) @ 0x0000000011841980 15. /build/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) @ 0x000000001621208e 16. /build/src/Storages/StorageReplicatedMergeTree.cpp:5228: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl[abi:se190107] const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000015f9a5fe 17. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000015ed8bfd 18. /build/src/Storages/StorageReplicatedMergeTree.cpp:2514: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x0000000015ec9aab 19. /build/src/Storages/StorageReplicatedMergeTree.cpp:2349: DB::StorageReplicatedMergeTree::executeLogEntry(DB::ReplicatedMergeTreeLogEntry&) @ 0x0000000015eba91b 20. /build/src/Storages/StorageReplicatedMergeTree.cpp:3876: bool std::__function::__policy_invoker&)>::__call_impl[abi:se190107])::$_1, bool (std::shared_ptr&)>>(std::__function::__policy_storage const*, std::shared_ptr&) @ 0x0000000015f9837e 21. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000165d6fc3 22. /build/src/Storages/StorageReplicatedMergeTree.cpp:3872: DB::StorageReplicatedMergeTree::processQueueEntry(std::shared_ptr) @ 0x0000000015efc18a 23. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001624c1b2 24. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000162f9c70 25. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x00000000162fa55a 26. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc6653 27. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000000fccc4c3 28. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc3d92 29. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fcca080 30. ? @ 0x00007fbc6213eac3 31. ? @ 0x00007fbc621d0850 (version 25.3.6.10636.altinitytest (altinity build)) 2025.07.28 11:54:15.917556 [ 17270 ] {4f46c9d5-e7dd-48ca-9d5e-b5670be602f2} executeQuery: Code: 69. DB::Exception: The number of shift positions needs to be a non-negative value: In scope SELECT bitShiftRight(toFixedString('hola', 8), -1). (ARGUMENT_OUT_OF_BOUND) (version 25.3.6.10636.altinitytest (altinity build)) (from [::1]:45758) (comment: 03198_bit_shift_throws_error_for_out_of_bounds.sql) (query 6, line 6) (in query: SELECT bitShiftRight(toFixedString('hola', 8), -1);), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000000a074fcb 4. /build/src/Functions/bitShiftRight.cpp:106: void DB::impl_::StringIntegerOperationImpl<_BitInt(8), DB::(anonymous namespace)::BitShiftRightImpl>::processFixedString<(DB::impl_::OpCase)0>(char8_t const*, unsigned long, DB::(anonymous namespace) const*, DB::PODArray, 63ul, 64ul>&, unsigned long) @ 0x000000000b046c25 5. /build/src/Functions/FunctionBinaryArithmetic.h:2149: _ZN2DBL16castTypeToEitherIJNS_14DataTypeNumberIDuEENS1_ItEENS1_IjEENS1_ImEENS1_IN4wide7integerILm128EjEEEENS1_INS7_ILm256EjEEEENS1_IDB8_EENS1_IsEENS1_IiEENS1_IlEENS1_INS7_ILm128EiEEEENS1_INS7_ILm256EiEEEENS_15DataTypeDecimalINS_7DecimalIiEEEENSL_INSM_IlEEEENSL_INSM_ISH_EEEENSL_INSM_ISJ_EEEENS_12DataTypeDateENS_16DataTypeDateTimeENS_19DataTypeFixedStringENS_14DataTypeStringENS_16DataTypeIntervalEENS_9IDataTypeEZZNS_24FunctionBinaryArithmeticINS_12_GLOBAL__N_117BitShiftRightImplENS12_17NameBitShiftRightELb1ELb0ELb0EE13castBothTypesIZNKS15_12executeImpl2ERKNSt3__16vectorINS_21ColumnWithTypeAndNameENS17_9allocatorIS19_EEEERKNS17_10shared_ptrIKS10_EEmPKNS_8PODArrayIDuLm4096E9AllocatorILb0ELb0EELm63ELm64EEEEUlRKT_RKT0_E_EEbPS1G_S1X_OS1Q_ENKUlS1S_E_clISX_EEDaS1S_EUlS1S_E_EEb8TypeListIJDpT_EEPS1U_OT1_ @ 0x000000000b0ab7ff 6. /build/src/Functions/FunctionBinaryArithmetic.h:838: DB::FunctionBinaryArithmetic::executeImpl2(std::vector> const&, std::shared_ptr const&, unsigned long, DB::PODArray, 63ul, 64ul> const*) const @ 0x000000000b05e4a1 7. /build/src/Functions/FunctionBinaryArithmetic.h:2410: DB::FunctionBinaryArithmetic::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000b05c7d7 8. /build/src/Functions/FunctionBinaryArithmetic.h:2645: DB::FunctionBinaryArithmeticWithConstants::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000b05b6f4 9. /build/src/Functions/IFunction.h:437: DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000a069f2a 10. /build/src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000012d9965a 11. /build/src/Functions/IFunction.cpp:351: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d93b02 12. /build/src/Functions/IFunction.cpp:420: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d95059 13. /build/src/Functions/IFunction.cpp:498: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d95c72 14. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3567: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000014034494 15. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3838: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000014019a9e 16. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3980: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000014018e31 17. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:4304: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000014042fa7 18. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5605: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000014013749 19. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000140127f9 20. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000014011fce 21. /build/src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000001406ce8a 22. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000014973b42 23. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000001497268d 24. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000014974d24 25. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001492924b 26. /build/src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88641 27. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 28. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 29. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 30. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 31. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 2025.07.28 11:54:15.937627 [ 17270 ] {} TCPHandler: Code: 69. DB::Exception: The number of shift positions needs to be a non-negative value: In scope SELECT bitShiftRight(toFixedString('hola', 8), -1). (ARGUMENT_OUT_OF_BOUND), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000000a074fcb 4. /build/src/Functions/bitShiftRight.cpp:106: void DB::impl_::StringIntegerOperationImpl<_BitInt(8), DB::(anonymous namespace)::BitShiftRightImpl>::processFixedString<(DB::impl_::OpCase)0>(char8_t const*, unsigned long, DB::(anonymous namespace) const*, DB::PODArray, 63ul, 64ul>&, unsigned long) @ 0x000000000b046c25 5. /build/src/Functions/FunctionBinaryArithmetic.h:2149: _ZN2DBL16castTypeToEitherIJNS_14DataTypeNumberIDuEENS1_ItEENS1_IjEENS1_ImEENS1_IN4wide7integerILm128EjEEEENS1_INS7_ILm256EjEEEENS1_IDB8_EENS1_IsEENS1_IiEENS1_IlEENS1_INS7_ILm128EiEEEENS1_INS7_ILm256EiEEEENS_15DataTypeDecimalINS_7DecimalIiEEEENSL_INSM_IlEEEENSL_INSM_ISH_EEEENSL_INSM_ISJ_EEEENS_12DataTypeDateENS_16DataTypeDateTimeENS_19DataTypeFixedStringENS_14DataTypeStringENS_16DataTypeIntervalEENS_9IDataTypeEZZNS_24FunctionBinaryArithmeticINS_12_GLOBAL__N_117BitShiftRightImplENS12_17NameBitShiftRightELb1ELb0ELb0EE13castBothTypesIZNKS15_12executeImpl2ERKNSt3__16vectorINS_21ColumnWithTypeAndNameENS17_9allocatorIS19_EEEERKNS17_10shared_ptrIKS10_EEmPKNS_8PODArrayIDuLm4096E9AllocatorILb0ELb0EELm63ELm64EEEEUlRKT_RKT0_E_EEbPS1G_S1X_OS1Q_ENKUlS1S_E_clISX_EEDaS1S_EUlS1S_E_EEb8TypeListIJDpT_EEPS1U_OT1_ @ 0x000000000b0ab7ff 6. /build/src/Functions/FunctionBinaryArithmetic.h:838: DB::FunctionBinaryArithmetic::executeImpl2(std::vector> const&, std::shared_ptr const&, unsigned long, DB::PODArray, 63ul, 64ul> const*) const @ 0x000000000b05e4a1 7. /build/src/Functions/FunctionBinaryArithmetic.h:2410: DB::FunctionBinaryArithmetic::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000b05c7d7 8. /build/src/Functions/FunctionBinaryArithmetic.h:2645: DB::FunctionBinaryArithmeticWithConstants::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000b05b6f4 9. /build/src/Functions/IFunction.h:437: DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000a069f2a 10. /build/src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000012d9965a 11. /build/src/Functions/IFunction.cpp:351: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d93b02 12. /build/src/Functions/IFunction.cpp:420: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d95059 13. /build/src/Functions/IFunction.cpp:498: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d95c72 14. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3567: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000014034494 15. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3838: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000014019a9e 16. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3980: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000014018e31 17. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:4304: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000014042fa7 18. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5605: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000014013749 19. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000140127f9 20. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000014011fce 21. /build/src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000001406ce8a 22. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000014973b42 23. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000001497268d 24. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000014974d24 25. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001492924b 26. /build/src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88641 27. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 28. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 29. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 30. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 31. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 2025.07.28 11:54:15.955242 [ 3283 ] {5def2667-3f54-404e-8cb6-c45f66861b69} executeQuery: Code: 1. DB::Exception: Resolved identifier 'item_id' in parent scope to expression 'l.item_id' with correlated column 'item_id'. In scope SELECT item_id FROM t1. (UNSUPPORTED_METHOD) (version 25.3.6.10636.altinitytest (altinity build)) (from [::1]:45790) (comment: 03255_parallel_replicas_join_algo_and_analyzer_4.sh) (query 5, line 7) (in query: --SELECT '----- enable_parallel_replicas=0 prefer_local_plan=0 parallel_replicas_prefer_local_join=0 -----'; SELECT sum(item_id) FROM ( SELECT item_id, price_sold FROM t ) AS l LEFT JOIN ( SELECT item_id FROM t1 ) AS r ON l.item_id = r.item_id GROUP BY price_sold ORDER BY price_sold ;), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/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 const&, String&&) @ 0x000000001404a1eb 4. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:1382: DB::QueryAnalyzer::tryResolveIdentifierInParentScopes(DB::IdentifierLookup const&, DB::IdentifierResolveScope&, DB::IdentifierResolveContext) @ 0x000000001402a8cc 5. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:1544: DB::QueryAnalyzer::tryResolveIdentifier(DB::IdentifierLookup const&, DB::IdentifierResolveScope&, DB::IdentifierResolveContext) @ 0x00000000140298dd 6. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3692: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000001401a2b4 7. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3980: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000014018e31 8. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:4304: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000014042fa7 9. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5605: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000014013749 10. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3870: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x00000000140199de 11. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5334: DB::QueryAnalyzer::resolveQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&) @ 0x00000000140454b0 12. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5142: DB::QueryAnalyzer::resolveJoin(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&) @ 0x0000000014046de9 13. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5361: DB::QueryAnalyzer::resolveQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&) @ 0x00000000140452d6 14. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5597: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000140136f0 15. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000140127f9 16. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000014011fce 17. /build/src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000001406ce8a 18. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000014973b42 19. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000001497268d 20. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000014974d24 21. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001492924b 22. /build/src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88641 23. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 24. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 25. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 26. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 27. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 28. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 29. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 30. ? @ 0x00007fbc6213eac3 31. ? @ 0x00007fbc621d0850 2025.07.28 11:54:16.016520 [ 3283 ] {} TCPHandler: Code: 1. DB::Exception: Resolved identifier 'item_id' in parent scope to expression 'l.item_id' with correlated column 'item_id'. In scope SELECT item_id FROM t1. (UNSUPPORTED_METHOD), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/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 const&, String&&) @ 0x000000001404a1eb 4. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:1382: DB::QueryAnalyzer::tryResolveIdentifierInParentScopes(DB::IdentifierLookup const&, DB::IdentifierResolveScope&, DB::IdentifierResolveContext) @ 0x000000001402a8cc 5. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:1544: DB::QueryAnalyzer::tryResolveIdentifier(DB::IdentifierLookup const&, DB::IdentifierResolveScope&, DB::IdentifierResolveContext) @ 0x00000000140298dd 6. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3692: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000001401a2b4 7. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3980: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000014018e31 8. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:4304: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000014042fa7 9. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5605: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000014013749 10. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3870: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x00000000140199de 11. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5334: DB::QueryAnalyzer::resolveQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&) @ 0x00000000140454b0 12. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5142: DB::QueryAnalyzer::resolveJoin(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&) @ 0x0000000014046de9 13. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5361: DB::QueryAnalyzer::resolveQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&) @ 0x00000000140452d6 14. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5597: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000140136f0 15. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000140127f9 16. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000014011fce 17. /build/src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000001406ce8a 18. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000014973b42 19. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000001497268d 20. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000014974d24 21. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001492924b 22. /build/src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88641 23. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 24. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 25. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 26. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 27. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 28. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 29. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 30. ? @ 0x00007fbc6213eac3 31. ? @ 0x00007fbc621d0850 2025.07.28 11:54:16.070984 [ 3961 ] {} test_13.rmt2 (7f9b740d-015c-470e-8cc6-8ba33be0dc63): auto DB::StorageReplicatedMergeTree::processQueueEntry(ReplicatedMergeTreeQueue::SelectedEntryPtr)::(anonymous class)::operator()(LogEntryPtr &) const: Code: 86. DB::HTTPException: Received error from remote server http://146b4357c08d:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Ftest%2F01165%2Ftest_13%2Frmt%2Freplicas%2F1&part=20250728_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.6.10636.altinitytest (altinity build)) '. (RECEIVED_ERROR_FROM_REMOTE_IO_SERVER), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.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 const&, int&&, String const&, unsigned long&&, String const&) @ 0x000000000feda8d9 4. /build/src/IO/HTTPCommon.cpp:104: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x000000000feda6e2 5. /build/src/IO/HTTPCommon.cpp:93: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x000000000feda537 6. /build/src/IO/ReadWriteBufferFromHTTP.cpp:277: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x000000001184a4c4 7. /build/src/IO/ReadWriteBufferFromHTTP.cpp:285: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x000000001184a615 8. /build/src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x000000001184ae59 9. /build/src/IO/ReadWriteBufferFromHTTP.cpp:472: void std::__function::__policy_invoker::__call_impl[abi:se190107]>(std::__function::__policy_storage const*) @ 0x000000001184cedd 10. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001184858b 11. /build/src/IO/ReadWriteBufferFromHTTP.cpp:465: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x000000001184bf0b 12. /build/src/IO/ReadBuffer.h:60: DB::ReadBuffer::next() @ 0x000000000a148c7b 13. /build/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) @ 0x0000000011849fb2 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]>&)>&, 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&) @ 0x0000000011841980 15. /build/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) @ 0x000000001621208e 16. /build/src/Storages/StorageReplicatedMergeTree.cpp:5228: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl[abi:se190107] const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000015f9a5fe 17. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000015ed8bfd 18. /build/src/Storages/StorageReplicatedMergeTree.cpp:2514: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x0000000015ec9aab 19. /build/src/Storages/StorageReplicatedMergeTree.cpp:2349: DB::StorageReplicatedMergeTree::executeLogEntry(DB::ReplicatedMergeTreeLogEntry&) @ 0x0000000015eba91b 20. /build/src/Storages/StorageReplicatedMergeTree.cpp:3876: bool std::__function::__policy_invoker&)>::__call_impl[abi:se190107])::$_1, bool (std::shared_ptr&)>>(std::__function::__policy_storage const*, std::shared_ptr&) @ 0x0000000015f9837e 21. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000165d6fc3 22. /build/src/Storages/StorageReplicatedMergeTree.cpp:3872: DB::StorageReplicatedMergeTree::processQueueEntry(std::shared_ptr) @ 0x0000000015efc18a 23. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001624c1b2 24. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000162f9c70 25. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x00000000162fa55a 26. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc6653 27. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000000fccc4c3 28. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc3d92 29. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fcca080 30. ? @ 0x00007fbc6213eac3 31. ? @ 0x00007fbc621d0850 (version 25.3.6.10636.altinitytest (altinity build)) 2025.07.28 11:54:16.543741 [ 17557 ] {9e62ea6d-4c5e-4f81-93a2-afcfeecd85ec} executeQuery: Code: 1. DB::Exception: Resolved identifier 'item_id' in parent scope to expression 'l.item_id' with correlated column 'item_id'. In scope SELECT item_id FROM t1. (UNSUPPORTED_METHOD) (version 25.3.6.10636.altinitytest (altinity build)) (from [::1]:45816) (comment: 03255_parallel_replicas_join_algo_and_analyzer_4.sh) (query 5, line 7) (in query: --SELECT '----- enable_parallel_replicas=1 prefer_local_plan=0 parallel_replicas_prefer_local_join=0 -----'; SELECT sum(item_id) FROM ( SELECT item_id, price_sold FROM t ) AS l LEFT JOIN ( SELECT item_id FROM t1 ) AS r ON l.item_id = r.item_id GROUP BY price_sold ORDER BY price_sold ;), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/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 const&, String&&) @ 0x000000001404a1eb 4. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:1382: DB::QueryAnalyzer::tryResolveIdentifierInParentScopes(DB::IdentifierLookup const&, DB::IdentifierResolveScope&, DB::IdentifierResolveContext) @ 0x000000001402a8cc 5. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:1544: DB::QueryAnalyzer::tryResolveIdentifier(DB::IdentifierLookup const&, DB::IdentifierResolveScope&, DB::IdentifierResolveContext) @ 0x00000000140298dd 6. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3692: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000001401a2b4 7. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3980: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000014018e31 8. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:4304: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000014042fa7 9. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5605: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000014013749 10. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3870: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x00000000140199de 11. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5334: DB::QueryAnalyzer::resolveQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&) @ 0x00000000140454b0 12. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5142: DB::QueryAnalyzer::resolveJoin(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&) @ 0x0000000014046de9 13. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5361: DB::QueryAnalyzer::resolveQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&) @ 0x00000000140452d6 14. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5597: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000140136f0 15. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000140127f9 16. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000014011fce 17. /build/src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000001406ce8a 18. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000014973b42 19. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000001497268d 20. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000014974d24 21. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001492924b 22. /build/src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88641 23. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 24. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 25. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 26. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 27. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 28. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 29. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 30. ? @ 0x00007fbc6213eac3 31. ? @ 0x00007fbc621d0850 2025.07.28 11:54:16.561023 [ 17557 ] {} TCPHandler: Code: 1. DB::Exception: Resolved identifier 'item_id' in parent scope to expression 'l.item_id' with correlated column 'item_id'. In scope SELECT item_id FROM t1. (UNSUPPORTED_METHOD), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/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 const&, String&&) @ 0x000000001404a1eb 4. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:1382: DB::QueryAnalyzer::tryResolveIdentifierInParentScopes(DB::IdentifierLookup const&, DB::IdentifierResolveScope&, DB::IdentifierResolveContext) @ 0x000000001402a8cc 5. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:1544: DB::QueryAnalyzer::tryResolveIdentifier(DB::IdentifierLookup const&, DB::IdentifierResolveScope&, DB::IdentifierResolveContext) @ 0x00000000140298dd 6. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3692: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000001401a2b4 7. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3980: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000014018e31 8. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:4304: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000014042fa7 9. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5605: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000014013749 10. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3870: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x00000000140199de 11. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5334: DB::QueryAnalyzer::resolveQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&) @ 0x00000000140454b0 12. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5142: DB::QueryAnalyzer::resolveJoin(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&) @ 0x0000000014046de9 13. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5361: DB::QueryAnalyzer::resolveQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&) @ 0x00000000140452d6 14. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5597: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000140136f0 15. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000140127f9 16. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000014011fce 17. /build/src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000001406ce8a 18. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000014973b42 19. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000001497268d 20. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000014974d24 21. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001492924b 22. /build/src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88641 23. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 24. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 25. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 26. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 27. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 28. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 29. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 30. ? @ 0x00007fbc6213eac3 31. ? @ 0x00007fbc621d0850 2025.07.28 11:54:16.680843 [ 17270 ] {2d758361-20fd-4b4f-bcfe-1cde6702adaf} executeQuery: Code: 69. DB::Exception: The number of shift positions needs to be a non-negative value: In scope SELECT bitShiftLeft(1, -1). (ARGUMENT_OUT_OF_BOUND) (version 25.3.6.10636.altinitytest (altinity build)) (from [::1]:45758) (comment: 03198_bit_shift_throws_error_for_out_of_bounds.sql) (query 9, line 10) (in query: SELECT bitShiftLeft(1, -1);), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000000a074fcb 4. /build/src/Functions/bitShiftLeft.cpp:29: DB::(anonymous namespace)::BitShiftLeftImpl DB::(anonymous namespace)::BitShiftLeftImpl::apply>(char8_t, DB::(anonymous namespace)::BitShiftLeftImpl) @ 0x000000000af74368 5. /build/src/Functions/FunctionBinaryArithmetic.h:309: _ZN2DBL16castTypeToEitherIJNS_14DataTypeNumberIDuEENS1_ItEENS1_IjEENS1_ImEENS1_IN4wide7integerILm128EjEEEENS1_INS7_ILm256EjEEEENS1_IDB8_EENS1_IsEENS1_IiEENS1_IlEENS1_INS7_ILm128EiEEEENS1_INS7_ILm256EiEEEENS_15DataTypeDecimalINS_7DecimalIiEEEENSL_INSM_IlEEEENSL_INSM_ISH_EEEENSL_INSM_ISJ_EEEENS_12DataTypeDateENS_16DataTypeDateTimeENS_19DataTypeFixedStringENS_14DataTypeStringENS_16DataTypeIntervalEENS_9IDataTypeEZZNS_24FunctionBinaryArithmeticINS_12_GLOBAL__N_116BitShiftLeftImplENS12_16NameBitShiftLeftELb1ELb0ELb0EE13castBothTypesIZNKS15_12executeImpl2ERKNSt3__16vectorINS_21ColumnWithTypeAndNameENS17_9allocatorIS19_EEEERKNS17_10shared_ptrIKS10_EEmPKNS_8PODArrayIDuLm4096E9AllocatorILb0ELb0EELm63ELm64EEEEUlRKT_RKT0_E_EEbPS1G_S1X_OS1Q_ENKUlS1S_E_clIS2_EEDaS1S_EUlS1S_E_EEb8TypeListIJDpT_EEPS1U_OT1_ @ 0x000000000afb9f8a 6. /build/src/Functions/FunctionBinaryArithmetic.h:838: DB::FunctionBinaryArithmetic::executeImpl2(std::vector> const&, std::shared_ptr const&, unsigned long, DB::PODArray, 63ul, 64ul> const*) const @ 0x000000000afb0e9c 7. /build/src/Functions/FunctionBinaryArithmetic.h:2410: DB::FunctionBinaryArithmetic::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000afaf917 8. /build/src/Functions/FunctionBinaryArithmetic.h:2645: DB::FunctionBinaryArithmeticWithConstants::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000afae834 9. /build/src/Functions/IFunction.h:437: DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000a069f2a 10. /build/src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000012d9965a 11. /build/src/Functions/IFunction.cpp:351: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d93b02 12. /build/src/Functions/IFunction.cpp:420: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d95059 13. /build/src/Functions/IFunction.cpp:498: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d95c72 14. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3567: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000014034494 15. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3838: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000014019a9e 16. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3980: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000014018e31 17. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:4304: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000014042fa7 18. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5605: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000014013749 19. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000140127f9 20. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000014011fce 21. /build/src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000001406ce8a 22. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000014973b42 23. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000001497268d 24. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000014974d24 25. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001492924b 26. /build/src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88641 27. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 28. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 29. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 30. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 31. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 2025.07.28 11:54:16.691780 [ 17270 ] {} TCPHandler: Code: 69. DB::Exception: The number of shift positions needs to be a non-negative value: In scope SELECT bitShiftLeft(1, -1). (ARGUMENT_OUT_OF_BOUND), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000000a074fcb 4. /build/src/Functions/bitShiftLeft.cpp:29: DB::(anonymous namespace)::BitShiftLeftImpl DB::(anonymous namespace)::BitShiftLeftImpl::apply>(char8_t, DB::(anonymous namespace)::BitShiftLeftImpl) @ 0x000000000af74368 5. /build/src/Functions/FunctionBinaryArithmetic.h:309: _ZN2DBL16castTypeToEitherIJNS_14DataTypeNumberIDuEENS1_ItEENS1_IjEENS1_ImEENS1_IN4wide7integerILm128EjEEEENS1_INS7_ILm256EjEEEENS1_IDB8_EENS1_IsEENS1_IiEENS1_IlEENS1_INS7_ILm128EiEEEENS1_INS7_ILm256EiEEEENS_15DataTypeDecimalINS_7DecimalIiEEEENSL_INSM_IlEEEENSL_INSM_ISH_EEEENSL_INSM_ISJ_EEEENS_12DataTypeDateENS_16DataTypeDateTimeENS_19DataTypeFixedStringENS_14DataTypeStringENS_16DataTypeIntervalEENS_9IDataTypeEZZNS_24FunctionBinaryArithmeticINS_12_GLOBAL__N_116BitShiftLeftImplENS12_16NameBitShiftLeftELb1ELb0ELb0EE13castBothTypesIZNKS15_12executeImpl2ERKNSt3__16vectorINS_21ColumnWithTypeAndNameENS17_9allocatorIS19_EEEERKNS17_10shared_ptrIKS10_EEmPKNS_8PODArrayIDuLm4096E9AllocatorILb0ELb0EELm63ELm64EEEEUlRKT_RKT0_E_EEbPS1G_S1X_OS1Q_ENKUlS1S_E_clIS2_EEDaS1S_EUlS1S_E_EEb8TypeListIJDpT_EEPS1U_OT1_ @ 0x000000000afb9f8a 6. /build/src/Functions/FunctionBinaryArithmetic.h:838: DB::FunctionBinaryArithmetic::executeImpl2(std::vector> const&, std::shared_ptr const&, unsigned long, DB::PODArray, 63ul, 64ul> const*) const @ 0x000000000afb0e9c 7. /build/src/Functions/FunctionBinaryArithmetic.h:2410: DB::FunctionBinaryArithmetic::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000afaf917 8. /build/src/Functions/FunctionBinaryArithmetic.h:2645: DB::FunctionBinaryArithmeticWithConstants::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000afae834 9. /build/src/Functions/IFunction.h:437: DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000a069f2a 10. /build/src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000012d9965a 11. /build/src/Functions/IFunction.cpp:351: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d93b02 12. /build/src/Functions/IFunction.cpp:420: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d95059 13. /build/src/Functions/IFunction.cpp:498: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d95c72 14. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3567: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000014034494 15. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3838: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000014019a9e 16. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3980: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000014018e31 17. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:4304: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000014042fa7 18. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5605: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000014013749 19. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000140127f9 20. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000014011fce 21. /build/src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000001406ce8a 22. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000014973b42 23. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000001497268d 24. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000014974d24 25. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001492924b 26. /build/src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88641 27. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 28. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 29. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 30. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 31. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 2025.07.28 11:54:16.758749 [ 17557 ] {fbbed7f6-3696-4542-a78a-2eed449e7412} executeQuery: Code: 1. DB::Exception: Resolved identifier 'item_id' in parent scope to expression 'l.item_id' with correlated column 'item_id'. In scope SELECT item_id FROM t1. (UNSUPPORTED_METHOD) (version 25.3.6.10636.altinitytest (altinity build)) (from [::1]:45828) (comment: 03255_parallel_replicas_join_algo_and_analyzer_4.sh) (query 5, line 7) (in query: --SELECT '----- enable_parallel_replicas=0 prefer_local_plan=1 parallel_replicas_prefer_local_join=0 -----'; SELECT sum(item_id) FROM ( SELECT item_id FROM t GROUP BY item_id ) AS l LEFT JOIN ( SELECT item_id FROM t1 ) AS r ON l.item_id = r.item_id ;), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/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 const&, String&&) @ 0x000000001404a1eb 4. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:1382: DB::QueryAnalyzer::tryResolveIdentifierInParentScopes(DB::IdentifierLookup const&, DB::IdentifierResolveScope&, DB::IdentifierResolveContext) @ 0x000000001402a8cc 5. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:1544: DB::QueryAnalyzer::tryResolveIdentifier(DB::IdentifierLookup const&, DB::IdentifierResolveScope&, DB::IdentifierResolveContext) @ 0x00000000140298dd 6. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3692: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000001401a2b4 7. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3980: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000014018e31 8. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:4304: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000014042fa7 9. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5605: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000014013749 10. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3870: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x00000000140199de 11. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5334: DB::QueryAnalyzer::resolveQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&) @ 0x00000000140454b0 12. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5142: DB::QueryAnalyzer::resolveJoin(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&) @ 0x0000000014046de9 13. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5361: DB::QueryAnalyzer::resolveQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&) @ 0x00000000140452d6 14. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5597: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000140136f0 15. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000140127f9 16. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000014011fce 17. /build/src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000001406ce8a 18. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000014973b42 19. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000001497268d 20. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000014974d24 21. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001492924b 22. /build/src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88641 23. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 24. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 25. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 26. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 27. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 28. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 29. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 30. ? @ 0x00007fbc6213eac3 31. ? @ 0x00007fbc621d0850 2025.07.28 11:54:16.770498 [ 3974 ] {} test_13.rmt2 (7f9b740d-015c-470e-8cc6-8ba33be0dc63): auto DB::StorageReplicatedMergeTree::processQueueEntry(ReplicatedMergeTreeQueue::SelectedEntryPtr)::(anonymous class)::operator()(LogEntryPtr &) const: Code: 86. DB::HTTPException: Received error from remote server http://146b4357c08d:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Ftest%2F01165%2Ftest_13%2Frmt%2Freplicas%2F1&part=20250728_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.6.10636.altinitytest (altinity build)) '. (RECEIVED_ERROR_FROM_REMOTE_IO_SERVER), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.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 const&, int&&, String const&, unsigned long&&, String const&) @ 0x000000000feda8d9 4. /build/src/IO/HTTPCommon.cpp:104: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x000000000feda6e2 5. /build/src/IO/HTTPCommon.cpp:93: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x000000000feda537 6. /build/src/IO/ReadWriteBufferFromHTTP.cpp:277: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x000000001184a4c4 7. /build/src/IO/ReadWriteBufferFromHTTP.cpp:285: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x000000001184a615 8. /build/src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x000000001184ae59 9. /build/src/IO/ReadWriteBufferFromHTTP.cpp:472: void std::__function::__policy_invoker::__call_impl[abi:se190107]>(std::__function::__policy_storage const*) @ 0x000000001184cedd 10. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001184858b 11. /build/src/IO/ReadWriteBufferFromHTTP.cpp:465: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x000000001184bf0b 12. /build/src/IO/ReadBuffer.h:60: DB::ReadBuffer::next() @ 0x000000000a148c7b 13. /build/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) @ 0x0000000011849fb2 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]>&)>&, 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&) @ 0x0000000011841980 15. /build/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) @ 0x000000001621208e 16. /build/src/Storages/StorageReplicatedMergeTree.cpp:5228: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl[abi:se190107] const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000015f9a5fe 17. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000015ed8bfd 18. /build/src/Storages/StorageReplicatedMergeTree.cpp:2514: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x0000000015ec9aab 19. /build/src/Storages/StorageReplicatedMergeTree.cpp:2349: DB::StorageReplicatedMergeTree::executeLogEntry(DB::ReplicatedMergeTreeLogEntry&) @ 0x0000000015eba91b 20. /build/src/Storages/StorageReplicatedMergeTree.cpp:3876: bool std::__function::__policy_invoker&)>::__call_impl[abi:se190107])::$_1, bool (std::shared_ptr&)>>(std::__function::__policy_storage const*, std::shared_ptr&) @ 0x0000000015f9837e 21. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000165d6fc3 22. /build/src/Storages/StorageReplicatedMergeTree.cpp:3872: DB::StorageReplicatedMergeTree::processQueueEntry(std::shared_ptr) @ 0x0000000015efc18a 23. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001624c1b2 24. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000162f9c70 25. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x00000000162fa55a 26. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc6653 27. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000000fccc4c3 28. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc3d92 29. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fcca080 30. ? @ 0x00007fbc6213eac3 31. ? @ 0x00007fbc621d0850 (version 25.3.6.10636.altinitytest (altinity build)) 2025.07.28 11:54:16.776240 [ 17557 ] {} TCPHandler: Code: 1. DB::Exception: Resolved identifier 'item_id' in parent scope to expression 'l.item_id' with correlated column 'item_id'. In scope SELECT item_id FROM t1. (UNSUPPORTED_METHOD), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/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 const&, String&&) @ 0x000000001404a1eb 4. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:1382: DB::QueryAnalyzer::tryResolveIdentifierInParentScopes(DB::IdentifierLookup const&, DB::IdentifierResolveScope&, DB::IdentifierResolveContext) @ 0x000000001402a8cc 5. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:1544: DB::QueryAnalyzer::tryResolveIdentifier(DB::IdentifierLookup const&, DB::IdentifierResolveScope&, DB::IdentifierResolveContext) @ 0x00000000140298dd 6. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3692: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000001401a2b4 7. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3980: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000014018e31 8. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:4304: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000014042fa7 9. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5605: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000014013749 10. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3870: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x00000000140199de 11. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5334: DB::QueryAnalyzer::resolveQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&) @ 0x00000000140454b0 12. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5142: DB::QueryAnalyzer::resolveJoin(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&) @ 0x0000000014046de9 13. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5361: DB::QueryAnalyzer::resolveQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&) @ 0x00000000140452d6 14. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5597: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000140136f0 15. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000140127f9 16. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000014011fce 17. /build/src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000001406ce8a 18. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000014973b42 19. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000001497268d 20. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000014974d24 21. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001492924b 22. /build/src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88641 23. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 24. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 25. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 26. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 27. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 28. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 29. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 30. ? @ 0x00007fbc6213eac3 31. ? @ 0x00007fbc621d0850 2025.07.28 11:54:16.932203 [ 17270 ] {0e82bd2c-d33c-4bbb-9738-4a57b0ff3268} executeQuery: Code: 69. DB::Exception: The number of shift positions needs to be a non-negative value: In scope SELECT bitShiftLeft('hola', -1). (ARGUMENT_OUT_OF_BOUND) (version 25.3.6.10636.altinitytest (altinity build)) (from [::1]:45758) (comment: 03198_bit_shift_throws_error_for_out_of_bounds.sql) (query 11, line 12) (in query: SELECT bitShiftLeft('hola', -1);), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000000a074fcb 4. /build/src/Functions/bitShiftLeft.cpp:49: void DB::impl_::StringIntegerOperationImpl<_BitInt(8), DB::(anonymous namespace)::BitShiftLeftImpl>::processString<(DB::impl_::OpCase)0>(char8_t const*, unsigned long const*, DB::(anonymous namespace) const*, DB::PODArray, 63ul, 64ul>&, Allocator, 63ul, 64ul>, 63ul, 64ul>&, unsigned long) @ 0x000000000af9f45c 5. /build/src/Functions/FunctionBinaryArithmetic.h:2154: _ZN2DBL16castTypeToEitherIJNS_14DataTypeNumberIDuEENS1_ItEENS1_IjEENS1_ImEENS1_IN4wide7integerILm128EjEEEENS1_INS7_ILm256EjEEEENS1_IDB8_EENS1_IsEENS1_IiEENS1_IlEENS1_INS7_ILm128EiEEEENS1_INS7_ILm256EiEEEENS_15DataTypeDecimalINS_7DecimalIiEEEENSL_INSM_IlEEEENSL_INSM_ISH_EEEENSL_INSM_ISJ_EEEENS_12DataTypeDateENS_16DataTypeDateTimeENS_19DataTypeFixedStringENS_14DataTypeStringENS_16DataTypeIntervalEENS_9IDataTypeEZZNS_24FunctionBinaryArithmeticINS_12_GLOBAL__N_116BitShiftLeftImplENS12_16NameBitShiftLeftELb1ELb0ELb0EE13castBothTypesIZNKS15_12executeImpl2ERKNSt3__16vectorINS_21ColumnWithTypeAndNameENS17_9allocatorIS19_EEEERKNS17_10shared_ptrIKS10_EEmPKNS_8PODArrayIDuLm4096E9AllocatorILb0ELb0EELm63ELm64EEEEUlRKT_RKT0_E_EEbPS1G_S1X_OS1Q_ENKUlS1S_E_clISY_EEDaS1S_EUlS1S_E_EEb8TypeListIJDpT_EEPS1U_OT1_ @ 0x000000000b001838 6. /build/src/Functions/FunctionBinaryArithmetic.h:838: DB::FunctionBinaryArithmetic::executeImpl2(std::vector> const&, std::shared_ptr const&, unsigned long, DB::PODArray, 63ul, 64ul> const*) const @ 0x000000000afb1655 7. /build/src/Functions/FunctionBinaryArithmetic.h:2410: DB::FunctionBinaryArithmetic::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000afaf917 8. /build/src/Functions/FunctionBinaryArithmetic.h:2645: DB::FunctionBinaryArithmeticWithConstants::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000afae834 9. /build/src/Functions/IFunction.h:437: DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000a069f2a 10. /build/src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000012d9965a 11. /build/src/Functions/IFunction.cpp:351: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d93b02 12. /build/src/Functions/IFunction.cpp:420: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d95059 13. /build/src/Functions/IFunction.cpp:498: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d95c72 14. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3567: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000014034494 15. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3838: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000014019a9e 16. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3980: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000014018e31 17. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:4304: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000014042fa7 18. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5605: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000014013749 19. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000140127f9 20. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000014011fce 21. /build/src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000001406ce8a 22. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000014973b42 23. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000001497268d 24. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000014974d24 25. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001492924b 26. /build/src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88641 27. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 28. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 29. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 30. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 31. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 2025.07.28 11:54:16.943233 [ 17270 ] {} TCPHandler: Code: 69. DB::Exception: The number of shift positions needs to be a non-negative value: In scope SELECT bitShiftLeft('hola', -1). (ARGUMENT_OUT_OF_BOUND), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000000a074fcb 4. /build/src/Functions/bitShiftLeft.cpp:49: void DB::impl_::StringIntegerOperationImpl<_BitInt(8), DB::(anonymous namespace)::BitShiftLeftImpl>::processString<(DB::impl_::OpCase)0>(char8_t const*, unsigned long const*, DB::(anonymous namespace) const*, DB::PODArray, 63ul, 64ul>&, Allocator, 63ul, 64ul>, 63ul, 64ul>&, unsigned long) @ 0x000000000af9f45c 5. /build/src/Functions/FunctionBinaryArithmetic.h:2154: _ZN2DBL16castTypeToEitherIJNS_14DataTypeNumberIDuEENS1_ItEENS1_IjEENS1_ImEENS1_IN4wide7integerILm128EjEEEENS1_INS7_ILm256EjEEEENS1_IDB8_EENS1_IsEENS1_IiEENS1_IlEENS1_INS7_ILm128EiEEEENS1_INS7_ILm256EiEEEENS_15DataTypeDecimalINS_7DecimalIiEEEENSL_INSM_IlEEEENSL_INSM_ISH_EEEENSL_INSM_ISJ_EEEENS_12DataTypeDateENS_16DataTypeDateTimeENS_19DataTypeFixedStringENS_14DataTypeStringENS_16DataTypeIntervalEENS_9IDataTypeEZZNS_24FunctionBinaryArithmeticINS_12_GLOBAL__N_116BitShiftLeftImplENS12_16NameBitShiftLeftELb1ELb0ELb0EE13castBothTypesIZNKS15_12executeImpl2ERKNSt3__16vectorINS_21ColumnWithTypeAndNameENS17_9allocatorIS19_EEEERKNS17_10shared_ptrIKS10_EEmPKNS_8PODArrayIDuLm4096E9AllocatorILb0ELb0EELm63ELm64EEEEUlRKT_RKT0_E_EEbPS1G_S1X_OS1Q_ENKUlS1S_E_clISY_EEDaS1S_EUlS1S_E_EEb8TypeListIJDpT_EEPS1U_OT1_ @ 0x000000000b001838 6. /build/src/Functions/FunctionBinaryArithmetic.h:838: DB::FunctionBinaryArithmetic::executeImpl2(std::vector> const&, std::shared_ptr const&, unsigned long, DB::PODArray, 63ul, 64ul> const*) const @ 0x000000000afb1655 7. /build/src/Functions/FunctionBinaryArithmetic.h:2410: DB::FunctionBinaryArithmetic::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000afaf917 8. /build/src/Functions/FunctionBinaryArithmetic.h:2645: DB::FunctionBinaryArithmeticWithConstants::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000afae834 9. /build/src/Functions/IFunction.h:437: DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000a069f2a 10. /build/src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000012d9965a 11. /build/src/Functions/IFunction.cpp:351: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d93b02 12. /build/src/Functions/IFunction.cpp:420: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d95059 13. /build/src/Functions/IFunction.cpp:498: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d95c72 14. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3567: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000014034494 15. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3838: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000014019a9e 16. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3980: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000014018e31 17. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:4304: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000014042fa7 18. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5605: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000014013749 19. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000140127f9 20. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000014011fce 21. /build/src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000001406ce8a 22. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000014973b42 23. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000001497268d 24. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000014974d24 25. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001492924b 26. /build/src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88641 27. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 28. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 29. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 30. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 31. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 2025.07.28 11:54:17.228800 [ 17270 ] {7e5c1325-c429-4d4e-a557-14bc036549a5} executeQuery: Code: 69. DB::Exception: The number of shift positions needs to be a non-negative value: In scope SELECT bitShiftLeft(toFixedString('hola', 8), -1). (ARGUMENT_OUT_OF_BOUND) (version 25.3.6.10636.altinitytest (altinity build)) (from [::1]:45758) (comment: 03198_bit_shift_throws_error_for_out_of_bounds.sql) (query 13, line 14) (in query: SELECT bitShiftLeft(toFixedString('hola', 8), -1);), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000000a074fcb 4. /build/src/Functions/bitShiftLeft.cpp:118: void DB::impl_::StringIntegerOperationImpl<_BitInt(8), DB::(anonymous namespace)::BitShiftLeftImpl>::processFixedString<(DB::impl_::OpCase)0>(char8_t const*, unsigned long, DB::(anonymous namespace) const*, DB::PODArray, 63ul, 64ul>&, unsigned long) @ 0x000000000af99f02 5. /build/src/Functions/FunctionBinaryArithmetic.h:2149: _ZN2DBL16castTypeToEitherIJNS_14DataTypeNumberIDuEENS1_ItEENS1_IjEENS1_ImEENS1_IN4wide7integerILm128EjEEEENS1_INS7_ILm256EjEEEENS1_IDB8_EENS1_IsEENS1_IiEENS1_IlEENS1_INS7_ILm128EiEEEENS1_INS7_ILm256EiEEEENS_15DataTypeDecimalINS_7DecimalIiEEEENSL_INSM_IlEEEENSL_INSM_ISH_EEEENSL_INSM_ISJ_EEEENS_12DataTypeDateENS_16DataTypeDateTimeENS_19DataTypeFixedStringENS_14DataTypeStringENS_16DataTypeIntervalEENS_9IDataTypeEZZNS_24FunctionBinaryArithmeticINS_12_GLOBAL__N_116BitShiftLeftImplENS12_16NameBitShiftLeftELb1ELb0ELb0EE13castBothTypesIZNKS15_12executeImpl2ERKNSt3__16vectorINS_21ColumnWithTypeAndNameENS17_9allocatorIS19_EEEERKNS17_10shared_ptrIKS10_EEmPKNS_8PODArrayIDuLm4096E9AllocatorILb0ELb0EELm63ELm64EEEEUlRKT_RKT0_E_EEbPS1G_S1X_OS1Q_ENKUlS1S_E_clISX_EEDaS1S_EUlS1S_E_EEb8TypeListIJDpT_EEPS1U_OT1_ @ 0x000000000affe23f 6. /build/src/Functions/FunctionBinaryArithmetic.h:838: DB::FunctionBinaryArithmetic::executeImpl2(std::vector> const&, std::shared_ptr const&, unsigned long, DB::PODArray, 63ul, 64ul> const*) const @ 0x000000000afb15e1 7. /build/src/Functions/FunctionBinaryArithmetic.h:2410: DB::FunctionBinaryArithmetic::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000afaf917 8. /build/src/Functions/FunctionBinaryArithmetic.h:2645: DB::FunctionBinaryArithmeticWithConstants::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000afae834 9. /build/src/Functions/IFunction.h:437: DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000a069f2a 10. /build/src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000012d9965a 11. /build/src/Functions/IFunction.cpp:351: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d93b02 12. /build/src/Functions/IFunction.cpp:420: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d95059 13. /build/src/Functions/IFunction.cpp:498: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d95c72 14. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3567: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000014034494 15. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3838: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000014019a9e 16. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3980: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000014018e31 17. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:4304: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000014042fa7 18. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5605: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000014013749 19. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000140127f9 20. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000014011fce 21. /build/src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000001406ce8a 22. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000014973b42 23. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000001497268d 24. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000014974d24 25. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001492924b 26. /build/src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88641 27. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 28. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 29. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 30. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 31. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 2025.07.28 11:54:17.242955 [ 17557 ] {0f15ea9f-58fd-4a58-ab81-931943e66386} executeQuery: Code: 1. DB::Exception: Resolved identifier 'item_id' in parent scope to expression 'l.item_id' with correlated column 'item_id'. In scope SELECT item_id FROM t1. (UNSUPPORTED_METHOD) (version 25.3.6.10636.altinitytest (altinity build)) (from [::1]:45848) (comment: 03255_parallel_replicas_join_algo_and_analyzer_4.sh) (query 5, line 7) (in query: --SELECT '----- enable_parallel_replicas=1 prefer_local_plan=1 parallel_replicas_prefer_local_join=0 -----'; SELECT sum(item_id) FROM ( SELECT item_id FROM t GROUP BY item_id ) AS l LEFT JOIN ( SELECT item_id FROM t1 ) AS r ON l.item_id = r.item_id ;), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/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 const&, String&&) @ 0x000000001404a1eb 4. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:1382: DB::QueryAnalyzer::tryResolveIdentifierInParentScopes(DB::IdentifierLookup const&, DB::IdentifierResolveScope&, DB::IdentifierResolveContext) @ 0x000000001402a8cc 5. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:1544: DB::QueryAnalyzer::tryResolveIdentifier(DB::IdentifierLookup const&, DB::IdentifierResolveScope&, DB::IdentifierResolveContext) @ 0x00000000140298dd 6. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3692: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000001401a2b4 7. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3980: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000014018e31 8. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:4304: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000014042fa7 9. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5605: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000014013749 10. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3870: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x00000000140199de 11. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5334: DB::QueryAnalyzer::resolveQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&) @ 0x00000000140454b0 12. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5142: DB::QueryAnalyzer::resolveJoin(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&) @ 0x0000000014046de9 13. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5361: DB::QueryAnalyzer::resolveQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&) @ 0x00000000140452d6 14. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5597: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000140136f0 15. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000140127f9 16. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000014011fce 17. /build/src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000001406ce8a 18. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000014973b42 19. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000001497268d 20. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000014974d24 21. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001492924b 22. /build/src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88641 23. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 24. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 25. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 26. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 27. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 28. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 29. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 30. ? @ 0x00007fbc6213eac3 31. ? @ 0x00007fbc621d0850 2025.07.28 11:54:17.272395 [ 17557 ] {} TCPHandler: Code: 1. DB::Exception: Resolved identifier 'item_id' in parent scope to expression 'l.item_id' with correlated column 'item_id'. In scope SELECT item_id FROM t1. (UNSUPPORTED_METHOD), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/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 const&, String&&) @ 0x000000001404a1eb 4. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:1382: DB::QueryAnalyzer::tryResolveIdentifierInParentScopes(DB::IdentifierLookup const&, DB::IdentifierResolveScope&, DB::IdentifierResolveContext) @ 0x000000001402a8cc 5. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:1544: DB::QueryAnalyzer::tryResolveIdentifier(DB::IdentifierLookup const&, DB::IdentifierResolveScope&, DB::IdentifierResolveContext) @ 0x00000000140298dd 6. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3692: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000001401a2b4 7. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3980: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000014018e31 8. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:4304: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000014042fa7 9. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5605: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000014013749 10. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3870: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x00000000140199de 11. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5334: DB::QueryAnalyzer::resolveQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&) @ 0x00000000140454b0 12. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5142: DB::QueryAnalyzer::resolveJoin(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&) @ 0x0000000014046de9 13. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5361: DB::QueryAnalyzer::resolveQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&) @ 0x00000000140452d6 14. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5597: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000140136f0 15. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000140127f9 16. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000014011fce 17. /build/src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000001406ce8a 18. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000014973b42 19. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000001497268d 20. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000014974d24 21. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001492924b 22. /build/src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88641 23. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 24. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 25. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 26. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 27. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 28. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 29. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 30. ? @ 0x00007fbc6213eac3 31. ? @ 0x00007fbc621d0850 2025.07.28 11:54:17.314636 [ 17270 ] {} TCPHandler: Code: 69. DB::Exception: The number of shift positions needs to be a non-negative value: In scope SELECT bitShiftLeft(toFixedString('hola', 8), -1). (ARGUMENT_OUT_OF_BOUND), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000000a074fcb 4. /build/src/Functions/bitShiftLeft.cpp:118: void DB::impl_::StringIntegerOperationImpl<_BitInt(8), DB::(anonymous namespace)::BitShiftLeftImpl>::processFixedString<(DB::impl_::OpCase)0>(char8_t const*, unsigned long, DB::(anonymous namespace) const*, DB::PODArray, 63ul, 64ul>&, unsigned long) @ 0x000000000af99f02 5. /build/src/Functions/FunctionBinaryArithmetic.h:2149: _ZN2DBL16castTypeToEitherIJNS_14DataTypeNumberIDuEENS1_ItEENS1_IjEENS1_ImEENS1_IN4wide7integerILm128EjEEEENS1_INS7_ILm256EjEEEENS1_IDB8_EENS1_IsEENS1_IiEENS1_IlEENS1_INS7_ILm128EiEEEENS1_INS7_ILm256EiEEEENS_15DataTypeDecimalINS_7DecimalIiEEEENSL_INSM_IlEEEENSL_INSM_ISH_EEEENSL_INSM_ISJ_EEEENS_12DataTypeDateENS_16DataTypeDateTimeENS_19DataTypeFixedStringENS_14DataTypeStringENS_16DataTypeIntervalEENS_9IDataTypeEZZNS_24FunctionBinaryArithmeticINS_12_GLOBAL__N_116BitShiftLeftImplENS12_16NameBitShiftLeftELb1ELb0ELb0EE13castBothTypesIZNKS15_12executeImpl2ERKNSt3__16vectorINS_21ColumnWithTypeAndNameENS17_9allocatorIS19_EEEERKNS17_10shared_ptrIKS10_EEmPKNS_8PODArrayIDuLm4096E9AllocatorILb0ELb0EELm63ELm64EEEEUlRKT_RKT0_E_EEbPS1G_S1X_OS1Q_ENKUlS1S_E_clISX_EEDaS1S_EUlS1S_E_EEb8TypeListIJDpT_EEPS1U_OT1_ @ 0x000000000affe23f 6. /build/src/Functions/FunctionBinaryArithmetic.h:838: DB::FunctionBinaryArithmetic::executeImpl2(std::vector> const&, std::shared_ptr const&, unsigned long, DB::PODArray, 63ul, 64ul> const*) const @ 0x000000000afb15e1 7. /build/src/Functions/FunctionBinaryArithmetic.h:2410: DB::FunctionBinaryArithmetic::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000afaf917 8. /build/src/Functions/FunctionBinaryArithmetic.h:2645: DB::FunctionBinaryArithmeticWithConstants::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000afae834 9. /build/src/Functions/IFunction.h:437: DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000a069f2a 10. /build/src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000012d9965a 11. /build/src/Functions/IFunction.cpp:351: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d93b02 12. /build/src/Functions/IFunction.cpp:420: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d95059 13. /build/src/Functions/IFunction.cpp:498: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d95c72 14. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3567: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000014034494 15. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3838: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000014019a9e 16. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3980: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000014018e31 17. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:4304: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000014042fa7 18. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5605: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000014013749 19. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000140127f9 20. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000014011fce 21. /build/src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000001406ce8a 22. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000014973b42 23. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000001497268d 24. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000014974d24 25. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001492924b 26. /build/src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88641 27. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 28. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 29. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 30. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 31. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 2025.07.28 11:54:17.450652 [ 5825 ] {5f288991-88d5-4878-a6fa-824bb06119a1} executeQuery: Code: 153. DB::Exception: Division by zero: while executing 'FUNCTION modulo(1_UInt8 :: 1, modulo(plus(__table1.number, 500_UInt16), 1000_UInt16) :: 2) -> modulo(1_UInt8, modulo(plus(__table1.number, 500_UInt16), 1000_UInt16)) UInt16 : 3'. (ILLEGAL_DIVISION) (version 25.3.6.10636.altinitytest (altinity build)) (from [::1]:45570) (comment: 00093_union_race_conditions_4.sh) (query 1, line 1) (in query: SELECT 1 % ((number + 500) % 1000) FROM numbers_mt(1000);), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000000a074fcb 4. /build/src/Functions/DivisionUtils.h:26: void DB::impl_::BinaryOperation, unsigned short>::process<(DB::impl_::OpCase)1>(char8_t const*, unsigned short const*, unsigned short*, unsigned long, DB::PODArray, 63ul, 64ul> const*) @ 0x000000000d184621 5. /build/src/Functions/FunctionBinaryArithmetic.h:2338: COW::immutable_ptr DB::FunctionBinaryArithmetic::executeNumeric, DB::DataTypeNumber>(std::vector> const&, DB::DataTypeNumber const&, DB::DataTypeNumber const&, DB::PODArray, 63ul, 64ul> const*) const @ 0x000000000d3a6416 6. /build/src/Functions/FunctionBinaryArithmetic.h:2508: 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&&) @ 0x000000000d3a4a68 7. /build/src/Functions/FunctionBinaryArithmetic.h:846: 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&&) @ 0x000000000d3a3ec7 8. /build/src/Functions/FunctionBinaryArithmetic.h:844: DB::FunctionBinaryArithmetic::executeImpl2(std::vector> const&, std::shared_ptr const&, unsigned long, DB::PODArray, 63ul, 64ul> const*) const @ 0x000000000d3a03c5 9. /build/src/Functions/FunctionBinaryArithmetic.h:2410: DB::FunctionBinaryArithmetic::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000d39e94c 10. /build/src/Functions/FunctionBinaryArithmetic.h:2645: DB::FunctionBinaryArithmeticWithConstants::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000d39dbd4 11. /build/src/Functions/IFunctionAdaptors.cpp:10: DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000012d995fa 12. /build/src/Functions/IFunction.cpp:353: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d93b52 13. /build/src/Functions/IFunction.cpp:420: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d95059 14. /build/src/Functions/IFunction.cpp:498: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d95c72 15. /build/src/Interpreters/ExpressionActions.cpp:636: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x00000000145176f3 16. /build/src/Processors/Transforms/ExpressionTransform.cpp:25: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x0000000016c0b34c 17. /build/src/Processors/ISimpleTransform.h:33: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000011a9a453 18. /build/src/Processors/ISimpleTransform.cpp:89: DB::ISimpleTransform::work() @ 0x000000001699fca0 19. /build/src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x00000000169bd00f 20. /build/src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x00000000169b2105 21. /build/src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeSingleThread(unsigned long) @ 0x00000000169b23be 22. /build/src/Processors/Executors/PipelineExecutor.cpp:454: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x00000000169b0be7 23. /build/src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x00000000169b03f4 24. /build/src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:se190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169bfeab 25. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc3d92 26. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fcca080 27. ? @ 0x00007fbc6213eac3 28. ? @ 0x00007fbc621d0850 2025.07.28 11:54:17.540678 [ 5825 ] {} TCPHandler: Code: 153. DB::Exception: Division by zero: while executing 'FUNCTION modulo(1_UInt8 :: 1, modulo(plus(__table1.number, 500_UInt16), 1000_UInt16) :: 2) -> modulo(1_UInt8, modulo(plus(__table1.number, 500_UInt16), 1000_UInt16)) UInt16 : 3'. (ILLEGAL_DIVISION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000000a074fcb 4. /build/src/Functions/DivisionUtils.h:26: void DB::impl_::BinaryOperation, unsigned short>::process<(DB::impl_::OpCase)1>(char8_t const*, unsigned short const*, unsigned short*, unsigned long, DB::PODArray, 63ul, 64ul> const*) @ 0x000000000d184621 5. /build/src/Functions/FunctionBinaryArithmetic.h:2338: COW::immutable_ptr DB::FunctionBinaryArithmetic::executeNumeric, DB::DataTypeNumber>(std::vector> const&, DB::DataTypeNumber const&, DB::DataTypeNumber const&, DB::PODArray, 63ul, 64ul> const*) const @ 0x000000000d3a6416 6. /build/src/Functions/FunctionBinaryArithmetic.h:2508: 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&&) @ 0x000000000d3a4a68 7. /build/src/Functions/FunctionBinaryArithmetic.h:846: 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&&) @ 0x000000000d3a3ec7 8. /build/src/Functions/FunctionBinaryArithmetic.h:844: DB::FunctionBinaryArithmetic::executeImpl2(std::vector> const&, std::shared_ptr const&, unsigned long, DB::PODArray, 63ul, 64ul> const*) const @ 0x000000000d3a03c5 9. /build/src/Functions/FunctionBinaryArithmetic.h:2410: DB::FunctionBinaryArithmetic::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000d39e94c 10. /build/src/Functions/FunctionBinaryArithmetic.h:2645: DB::FunctionBinaryArithmeticWithConstants::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000d39dbd4 11. /build/src/Functions/IFunctionAdaptors.cpp:10: DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000012d995fa 12. /build/src/Functions/IFunction.cpp:353: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d93b52 13. /build/src/Functions/IFunction.cpp:420: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d95059 14. /build/src/Functions/IFunction.cpp:498: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d95c72 15. /build/src/Interpreters/ExpressionActions.cpp:636: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x00000000145176f3 16. /build/src/Processors/Transforms/ExpressionTransform.cpp:25: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x0000000016c0b34c 17. /build/src/Processors/ISimpleTransform.h:33: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000011a9a453 18. /build/src/Processors/ISimpleTransform.cpp:89: DB::ISimpleTransform::work() @ 0x000000001699fca0 19. /build/src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x00000000169bd00f 20. /build/src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x00000000169b2105 21. /build/src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeSingleThread(unsigned long) @ 0x00000000169b23be 22. /build/src/Processors/Executors/PipelineExecutor.cpp:454: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x00000000169b0be7 23. /build/src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x00000000169b03f4 24. /build/src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:se190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169bfeab 25. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc3d92 26. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fcca080 27. ? @ 0x00007fbc6213eac3 28. ? @ 0x00007fbc621d0850 Job's origin stack trace: 0. /build/src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000000fc33b84 1. /build/src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000000fcc2ea7 2. /build/src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fcc535c 3. /build/src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000000fcc584d 4. /build/src/Common/ThreadPool.h:279: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x00000000169bf193 5. /build/src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x00000000169bf518 6. /build/src/Server/TCPHandler.cpp:1237: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x00000000168f1525 7. /build/src/Server/TCPHandler.cpp:678: DB::TCPHandler::runImpl() @ 0x00000000168e68e5 8. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 9. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 10. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 11. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 12. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 13. ? @ 0x00007fbc6213eac3 14. ? @ 0x00007fbc621d0850 2025.07.28 11:54:17.636226 [ 3971 ] {} test_13.rmt2 (7f9b740d-015c-470e-8cc6-8ba33be0dc63): auto DB::StorageReplicatedMergeTree::processQueueEntry(ReplicatedMergeTreeQueue::SelectedEntryPtr)::(anonymous class)::operator()(LogEntryPtr &) const: Code: 86. DB::HTTPException: Received error from remote server http://146b4357c08d:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Ftest%2F01165%2Ftest_13%2Frmt%2Freplicas%2F1&part=20250728_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.6.10636.altinitytest (altinity build)) '. (RECEIVED_ERROR_FROM_REMOTE_IO_SERVER), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.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 const&, int&&, String const&, unsigned long&&, String const&) @ 0x000000000feda8d9 4. /build/src/IO/HTTPCommon.cpp:104: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x000000000feda6e2 5. /build/src/IO/HTTPCommon.cpp:93: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x000000000feda537 6. /build/src/IO/ReadWriteBufferFromHTTP.cpp:277: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x000000001184a4c4 7. /build/src/IO/ReadWriteBufferFromHTTP.cpp:285: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x000000001184a615 8. /build/src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x000000001184ae59 9. /build/src/IO/ReadWriteBufferFromHTTP.cpp:472: void std::__function::__policy_invoker::__call_impl[abi:se190107]>(std::__function::__policy_storage const*) @ 0x000000001184cedd 10. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001184858b 11. /build/src/IO/ReadWriteBufferFromHTTP.cpp:465: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x000000001184bf0b 12. /build/src/IO/ReadBuffer.h:60: DB::ReadBuffer::next() @ 0x000000000a148c7b 13. /build/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) @ 0x0000000011849fb2 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]>&)>&, 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&) @ 0x0000000011841980 15. /build/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) @ 0x000000001621208e 16. /build/src/Storages/StorageReplicatedMergeTree.cpp:5228: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl[abi:se190107] const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000015f9a5fe 17. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000015ed8bfd 18. /build/src/Storages/StorageReplicatedMergeTree.cpp:2514: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x0000000015ec9aab 19. /build/src/Storages/StorageReplicatedMergeTree.cpp:2349: DB::StorageReplicatedMergeTree::executeLogEntry(DB::ReplicatedMergeTreeLogEntry&) @ 0x0000000015eba91b 20. /build/src/Storages/StorageReplicatedMergeTree.cpp:3876: bool std::__function::__policy_invoker&)>::__call_impl[abi:se190107])::$_1, bool (std::shared_ptr&)>>(std::__function::__policy_storage const*, std::shared_ptr&) @ 0x0000000015f9837e 21. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000165d6fc3 22. /build/src/Storages/StorageReplicatedMergeTree.cpp:3872: DB::StorageReplicatedMergeTree::processQueueEntry(std::shared_ptr) @ 0x0000000015efc18a 23. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001624c1b2 24. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000162f9c70 25. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x00000000162fa55a 26. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc6653 27. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000000fccc4c3 28. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc3d92 29. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fcca080 30. ? @ 0x00007fbc6213eac3 31. ? @ 0x00007fbc621d0850 (version 25.3.6.10636.altinitytest (altinity build)) 2025.07.28 11:54:17.697124 [ 17557 ] {60ec75c3-61ff-49a2-93b8-776bc3731630} executeQuery: Code: 1. DB::Exception: Resolved identifier 'item_id' in parent scope to expression 'l.item_id' with correlated column 'item_id'. In scope SELECT item_id FROM t1 GROUP BY item_id. (UNSUPPORTED_METHOD) (version 25.3.6.10636.altinitytest (altinity build)) (from [::1]:45878) (comment: 03255_parallel_replicas_join_algo_and_analyzer_4.sh) (query 5, line 7) (in query: --SELECT '----- enable_parallel_replicas=0 prefer_local_plan=1 parallel_replicas_prefer_local_join=0 -----'; SELECT sum(item_id) FROM ( SELECT item_id FROM t ) AS l LEFT JOIN ( SELECT item_id FROM t1 GROUP BY item_id ) AS r ON l.item_id = r.item_id ;), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/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 const&, String&&) @ 0x000000001404a1eb 4. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:1382: DB::QueryAnalyzer::tryResolveIdentifierInParentScopes(DB::IdentifierLookup const&, DB::IdentifierResolveScope&, DB::IdentifierResolveContext) @ 0x000000001402a8cc 5. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:1544: DB::QueryAnalyzer::tryResolveIdentifier(DB::IdentifierLookup const&, DB::IdentifierResolveScope&, DB::IdentifierResolveContext) @ 0x00000000140298dd 6. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3692: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000001401a2b4 7. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3980: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000014018e31 8. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:4304: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000014042fa7 9. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5605: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000014013749 10. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3870: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x00000000140199de 11. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5334: DB::QueryAnalyzer::resolveQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&) @ 0x00000000140454b0 12. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5142: DB::QueryAnalyzer::resolveJoin(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&) @ 0x0000000014046de9 13. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5361: DB::QueryAnalyzer::resolveQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&) @ 0x00000000140452d6 14. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5597: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000140136f0 15. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000140127f9 16. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000014011fce 17. /build/src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000001406ce8a 18. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000014973b42 19. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000001497268d 20. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000014974d24 21. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001492924b 22. /build/src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88641 23. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 24. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 25. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 26. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 27. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 28. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 29. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 30. ? @ 0x00007fbc6213eac3 31. ? @ 0x00007fbc621d0850 2025.07.28 11:54:17.704060 [ 17557 ] {} TCPHandler: Code: 1. DB::Exception: Resolved identifier 'item_id' in parent scope to expression 'l.item_id' with correlated column 'item_id'. In scope SELECT item_id FROM t1 GROUP BY item_id. (UNSUPPORTED_METHOD), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/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 const&, String&&) @ 0x000000001404a1eb 4. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:1382: DB::QueryAnalyzer::tryResolveIdentifierInParentScopes(DB::IdentifierLookup const&, DB::IdentifierResolveScope&, DB::IdentifierResolveContext) @ 0x000000001402a8cc 5. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:1544: DB::QueryAnalyzer::tryResolveIdentifier(DB::IdentifierLookup const&, DB::IdentifierResolveScope&, DB::IdentifierResolveContext) @ 0x00000000140298dd 6. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3692: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000001401a2b4 7. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3980: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000014018e31 8. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:4304: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000014042fa7 9. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5605: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000014013749 10. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3870: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x00000000140199de 11. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5334: DB::QueryAnalyzer::resolveQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&) @ 0x00000000140454b0 12. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5142: DB::QueryAnalyzer::resolveJoin(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&) @ 0x0000000014046de9 13. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5361: DB::QueryAnalyzer::resolveQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&) @ 0x00000000140452d6 14. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5597: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000140136f0 15. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000140127f9 16. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000014011fce 17. /build/src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000001406ce8a 18. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000014973b42 19. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000001497268d 20. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000014974d24 21. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001492924b 22. /build/src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88641 23. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 24. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 25. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 26. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 27. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 28. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 29. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 30. ? @ 0x00007fbc6213eac3 31. ? @ 0x00007fbc621d0850 2025.07.28 11:54:18.060039 [ 17557 ] {76112a9b-842f-497e-9bc2-77cde2360d1d} executeQuery: Code: 1. DB::Exception: Resolved identifier 'item_id' in parent scope to expression 'l.item_id' with correlated column 'item_id'. In scope SELECT item_id FROM t1 GROUP BY item_id. (UNSUPPORTED_METHOD) (version 25.3.6.10636.altinitytest (altinity build)) (from [::1]:45926) (comment: 03255_parallel_replicas_join_algo_and_analyzer_4.sh) (query 5, line 7) (in query: --SELECT '----- enable_parallel_replicas=1 prefer_local_plan=1 parallel_replicas_prefer_local_join=0 -----'; SELECT sum(item_id) FROM ( SELECT item_id FROM t ) AS l LEFT JOIN ( SELECT item_id FROM t1 GROUP BY item_id ) AS r ON l.item_id = r.item_id ;), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/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 const&, String&&) @ 0x000000001404a1eb 4. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:1382: DB::QueryAnalyzer::tryResolveIdentifierInParentScopes(DB::IdentifierLookup const&, DB::IdentifierResolveScope&, DB::IdentifierResolveContext) @ 0x000000001402a8cc 5. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:1544: DB::QueryAnalyzer::tryResolveIdentifier(DB::IdentifierLookup const&, DB::IdentifierResolveScope&, DB::IdentifierResolveContext) @ 0x00000000140298dd 6. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3692: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000001401a2b4 7. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3980: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000014018e31 8. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:4304: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000014042fa7 9. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5605: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000014013749 10. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3870: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x00000000140199de 11. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5334: DB::QueryAnalyzer::resolveQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&) @ 0x00000000140454b0 12. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5142: DB::QueryAnalyzer::resolveJoin(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&) @ 0x0000000014046de9 13. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5361: DB::QueryAnalyzer::resolveQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&) @ 0x00000000140452d6 14. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5597: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000140136f0 15. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000140127f9 16. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000014011fce 17. /build/src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000001406ce8a 18. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000014973b42 19. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000001497268d 20. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000014974d24 21. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001492924b 22. /build/src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88641 23. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 24. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 25. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 26. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 27. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 28. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 29. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 30. ? @ 0x00007fbc6213eac3 31. ? @ 0x00007fbc621d0850 2025.07.28 11:54:18.081890 [ 3287 ] {6c3f2bf5-1d19-47c2-889d-5fa1376ed80f} executeQuery: Code: 43. DB::Exception: Illegal types Array(UInt8) and String of arguments of function divide: In scope SELECT [1] / 'a'. (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.6.10636.altinitytest (altinity build)) (from [::1]:45712) (comment: 02883_array_scalar_mult_div_modulo.sql) (query 25, line 25) (in query: SELECT [1] / 'a';), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&) @ 0x000000000a10182b 4. /build/src/Functions/FunctionBinaryArithmetic.h:1931: DB::FunctionBinaryArithmetic::getReturnTypeImplStatic(std::vector, std::allocator>> const&, std::shared_ptr) @ 0x000000000b5dc502 5. /build/src/Functions/IFunction.h:369: DB::IFunctionOverloadResolver::getReturnTypeImpl(std::vector> const&) const @ 0x000000000a6646de 6. /build/src/Functions/IFunction.cpp:645: DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x0000000012d96b0c 7. /build/src/Functions/IFunction.cpp:577: DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x0000000012d9669c 8. /build/src/Functions/IFunction.cpp:606: DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x0000000012d96edc 9. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3544: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000014033cc9 10. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3838: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000014019a9e 11. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3980: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000014018e31 12. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:4304: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000014042fa7 13. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5605: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000014013749 14. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000140127f9 15. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000014011fce 16. /build/src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000001406ce8a 17. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000014973b42 18. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000001497268d 19. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000014974d24 20. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001492924b 21. /build/src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88641 22. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 23. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 24. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 25. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 26. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 27. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 28. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 29. ? @ 0x00007fbc6213eac3 30. ? @ 0x00007fbc621d0850 2025.07.28 11:54:18.168189 [ 17557 ] {} TCPHandler: Code: 1. DB::Exception: Resolved identifier 'item_id' in parent scope to expression 'l.item_id' with correlated column 'item_id'. In scope SELECT item_id FROM t1 GROUP BY item_id. (UNSUPPORTED_METHOD), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/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 const&, String&&) @ 0x000000001404a1eb 4. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:1382: DB::QueryAnalyzer::tryResolveIdentifierInParentScopes(DB::IdentifierLookup const&, DB::IdentifierResolveScope&, DB::IdentifierResolveContext) @ 0x000000001402a8cc 5. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:1544: DB::QueryAnalyzer::tryResolveIdentifier(DB::IdentifierLookup const&, DB::IdentifierResolveScope&, DB::IdentifierResolveContext) @ 0x00000000140298dd 6. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3692: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000001401a2b4 7. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3980: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000014018e31 8. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:4304: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000014042fa7 9. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5605: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000014013749 10. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3870: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x00000000140199de 11. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5334: DB::QueryAnalyzer::resolveQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&) @ 0x00000000140454b0 12. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5142: DB::QueryAnalyzer::resolveJoin(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&) @ 0x0000000014046de9 13. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5361: DB::QueryAnalyzer::resolveQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&) @ 0x00000000140452d6 14. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5597: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000140136f0 15. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000140127f9 16. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000014011fce 17. /build/src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000001406ce8a 18. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000014973b42 19. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000001497268d 20. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000014974d24 21. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001492924b 22. /build/src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88641 23. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 24. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 25. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 26. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 27. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 28. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 29. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 30. ? @ 0x00007fbc6213eac3 31. ? @ 0x00007fbc621d0850 2025.07.28 11:54:18.161160 [ 3287 ] {} TCPHandler: Code: 43. DB::Exception: Illegal types Array(UInt8) and String of arguments of function divide: In scope SELECT [1] / 'a'. (ILLEGAL_TYPE_OF_ARGUMENT), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&) @ 0x000000000a10182b 4. /build/src/Functions/FunctionBinaryArithmetic.h:1931: DB::FunctionBinaryArithmetic::getReturnTypeImplStatic(std::vector, std::allocator>> const&, std::shared_ptr) @ 0x000000000b5dc502 5. /build/src/Functions/IFunction.h:369: DB::IFunctionOverloadResolver::getReturnTypeImpl(std::vector> const&) const @ 0x000000000a6646de 6. /build/src/Functions/IFunction.cpp:645: DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x0000000012d96b0c 7. /build/src/Functions/IFunction.cpp:577: DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x0000000012d9669c 8. /build/src/Functions/IFunction.cpp:606: DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x0000000012d96edc 9. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3544: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000014033cc9 10. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3838: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000014019a9e 11. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3980: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000014018e31 12. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:4304: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000014042fa7 13. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5605: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000014013749 14. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000140127f9 15. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000014011fce 16. /build/src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000001406ce8a 17. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000014973b42 18. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000001497268d 19. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000014974d24 20. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001492924b 21. /build/src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88641 22. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 23. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 24. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 25. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 26. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 27. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 28. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 29. ? @ 0x00007fbc6213eac3 30. ? @ 0x00007fbc621d0850 2025.07.28 11:54:18.190606 [ 3968 ] {} test_13.rmt2 (7f9b740d-015c-470e-8cc6-8ba33be0dc63): auto DB::StorageReplicatedMergeTree::processQueueEntry(ReplicatedMergeTreeQueue::SelectedEntryPtr)::(anonymous class)::operator()(LogEntryPtr &) const: Code: 86. DB::HTTPException: Received error from remote server http://146b4357c08d:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Ftest%2F01165%2Ftest_13%2Frmt%2Freplicas%2F1&part=20250728_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.6.10636.altinitytest (altinity build)) '. (RECEIVED_ERROR_FROM_REMOTE_IO_SERVER), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.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 const&, int&&, String const&, unsigned long&&, String const&) @ 0x000000000feda8d9 4. /build/src/IO/HTTPCommon.cpp:104: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x000000000feda6e2 5. /build/src/IO/HTTPCommon.cpp:93: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x000000000feda537 6. /build/src/IO/ReadWriteBufferFromHTTP.cpp:277: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x000000001184a4c4 7. /build/src/IO/ReadWriteBufferFromHTTP.cpp:285: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x000000001184a615 8. /build/src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x000000001184ae59 9. /build/src/IO/ReadWriteBufferFromHTTP.cpp:472: void std::__function::__policy_invoker::__call_impl[abi:se190107]>(std::__function::__policy_storage const*) @ 0x000000001184cedd 10. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001184858b 11. /build/src/IO/ReadWriteBufferFromHTTP.cpp:465: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x000000001184bf0b 12. /build/src/IO/ReadBuffer.h:60: DB::ReadBuffer::next() @ 0x000000000a148c7b 13. /build/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) @ 0x0000000011849fb2 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]>&)>&, 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&) @ 0x0000000011841980 15. /build/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) @ 0x000000001621208e 16. /build/src/Storages/StorageReplicatedMergeTree.cpp:5228: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl[abi:se190107] const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000015f9a5fe 17. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000015ed8bfd 18. /build/src/Storages/StorageReplicatedMergeTree.cpp:2514: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x0000000015ec9aab 19. /build/src/Storages/StorageReplicatedMergeTree.cpp:2349: DB::StorageReplicatedMergeTree::executeLogEntry(DB::ReplicatedMergeTreeLogEntry&) @ 0x0000000015eba91b 20. /build/src/Storages/StorageReplicatedMergeTree.cpp:3876: bool std::__function::__policy_invoker&)>::__call_impl[abi:se190107])::$_1, bool (std::shared_ptr&)>>(std::__function::__policy_storage const*, std::shared_ptr&) @ 0x0000000015f9837e 21. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000165d6fc3 22. /build/src/Storages/StorageReplicatedMergeTree.cpp:3872: DB::StorageReplicatedMergeTree::processQueueEntry(std::shared_ptr) @ 0x0000000015efc18a 23. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001624c1b2 24. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000162f9c70 25. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x00000000162fa55a 26. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc6653 27. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000000fccc4c3 28. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc3d92 29. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fcca080 30. ? @ 0x00007fbc6213eac3 31. ? @ 0x00007fbc621d0850 (version 25.3.6.10636.altinitytest (altinity build)) 2025.07.28 11:54:18.508306 [ 17557 ] {9f68867d-e5ff-41d3-9502-cc0761505109} executeQuery: Code: 1. DB::Exception: Resolved identifier 'item_id' in parent scope to expression 'l.item_id' with correlated column 'item_id'. In scope SELECT item_id FROM t1. (UNSUPPORTED_METHOD) (version 25.3.6.10636.altinitytest (altinity build)) (from [::1]:45938) (comment: 03255_parallel_replicas_join_algo_and_analyzer_4.sh) (query 5, line 7) (in query: --SELECT '----- enable_parallel_replicas=0 prefer_local_plan=1 parallel_replicas_prefer_local_join=0 -----'; SELECT sum(item_id) FROM ( SELECT item_id, price_sold FROM t ) AS l LEFT JOIN ( SELECT item_id FROM t1 ) AS r ON l.item_id = r.item_id GROUP BY price_sold ORDER BY price_sold ;), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/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 const&, String&&) @ 0x000000001404a1eb 4. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:1382: DB::QueryAnalyzer::tryResolveIdentifierInParentScopes(DB::IdentifierLookup const&, DB::IdentifierResolveScope&, DB::IdentifierResolveContext) @ 0x000000001402a8cc 5. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:1544: DB::QueryAnalyzer::tryResolveIdentifier(DB::IdentifierLookup const&, DB::IdentifierResolveScope&, DB::IdentifierResolveContext) @ 0x00000000140298dd 6. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3692: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000001401a2b4 7. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3980: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000014018e31 8. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:4304: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000014042fa7 9. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5605: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000014013749 10. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3870: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x00000000140199de 11. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5334: DB::QueryAnalyzer::resolveQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&) @ 0x00000000140454b0 12. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5142: DB::QueryAnalyzer::resolveJoin(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&) @ 0x0000000014046de9 13. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5361: DB::QueryAnalyzer::resolveQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&) @ 0x00000000140452d6 14. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5597: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000140136f0 15. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000140127f9 16. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000014011fce 17. /build/src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000001406ce8a 18. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000014973b42 19. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000001497268d 20. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000014974d24 21. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001492924b 22. /build/src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88641 23. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 24. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 25. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 26. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 27. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 28. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 29. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 30. ? @ 0x00007fbc6213eac3 31. ? @ 0x00007fbc621d0850 2025.07.28 11:54:18.535901 [ 17557 ] {} TCPHandler: Code: 1. DB::Exception: Resolved identifier 'item_id' in parent scope to expression 'l.item_id' with correlated column 'item_id'. In scope SELECT item_id FROM t1. (UNSUPPORTED_METHOD), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/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 const&, String&&) @ 0x000000001404a1eb 4. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:1382: DB::QueryAnalyzer::tryResolveIdentifierInParentScopes(DB::IdentifierLookup const&, DB::IdentifierResolveScope&, DB::IdentifierResolveContext) @ 0x000000001402a8cc 5. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:1544: DB::QueryAnalyzer::tryResolveIdentifier(DB::IdentifierLookup const&, DB::IdentifierResolveScope&, DB::IdentifierResolveContext) @ 0x00000000140298dd 6. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3692: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000001401a2b4 7. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3980: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000014018e31 8. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:4304: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000014042fa7 9. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5605: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000014013749 10. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3870: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x00000000140199de 11. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5334: DB::QueryAnalyzer::resolveQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&) @ 0x00000000140454b0 12. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5142: DB::QueryAnalyzer::resolveJoin(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&) @ 0x0000000014046de9 13. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5361: DB::QueryAnalyzer::resolveQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&) @ 0x00000000140452d6 14. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5597: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000140136f0 15. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000140127f9 16. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000014011fce 17. /build/src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000001406ce8a 18. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000014973b42 19. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000001497268d 20. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000014974d24 21. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001492924b 22. /build/src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88641 23. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 24. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 25. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 26. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 27. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 28. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 29. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 30. ? @ 0x00007fbc6213eac3 31. ? @ 0x00007fbc621d0850 2025.07.28 11:54:18.535873 [ 17191 ] {7faa4cb2-5b69-4c94-9b76-51fcc602e8ab} executeQuery: Code: 47. DB::Exception: Unknown expression or function identifier `x` in scope x = 1. (UNKNOWN_IDENTIFIER) (version 25.3.6.10636.altinitytest (altinity build)) (from [::1]:45890) (comment: 01278_alter_rename_combination.sql) (query 6, line 12) (in query: SELECT * FROM rename_table FORMAT TSVWithNames;), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.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&&) @ 0x000000001404b3b9 4. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3771: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000001401b849 5. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3980: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000014018e31 6. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:2925: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000001402fcbd 7. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3838: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000014019a9e 8. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:209: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000001401270e 9. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000014011fce 10. /build/src/Planner/Utils.cpp:458: DB::buildFilterInfo(std::shared_ptr, std::shared_ptr const&, std::shared_ptr&, std::unordered_set, std::equal_to, std::allocator>) @ 0x0000000013fe8bcf 11. /build/src/Planner/PlannerJoinTree.cpp:535: DB::(anonymous namespace)::buildQueryPlanForTableExpression(std::shared_ptr, std::shared_ptr const&, DB::SelectQueryInfo const&, DB::SelectQueryOptions const&, std::shared_ptr&, bool, bool) @ 0x00000000149956d3 12. /build/src/Planner/PlannerJoinTree.cpp:2252: DB::buildJoinTreeQueryPlan(std::shared_ptr const&, DB::SelectQueryInfo const&, DB::SelectQueryOptions&, std::unordered_set, std::equal_to, std::allocator> const&, std::shared_ptr&) @ 0x000000001498e109 13. /build/src/Planner/Planner.cpp:1553: DB::Planner::buildPlanForQueryNode() @ 0x0000000014979dae 14. /build/src/Planner/Planner.cpp:1308: DB::Planner::buildQueryPlanIfNeeded() @ 0x000000001497685c 15. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:255: DB::InterpreterSelectQueryAnalyzer::getQueryPlan() @ 0x000000001497476d 16. /build/src/Interpreters/executeQuery.cpp:1405: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88806 17. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 18. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 19. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 20. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 21. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 22. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 23. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 24. ? @ 0x00007fbc6213eac3 25. ? @ 0x00007fbc621d0850 2025.07.28 11:54:18.552118 [ 17191 ] {} TCPHandler: Code: 47. DB::Exception: Unknown expression or function identifier `x` in scope x = 1. (UNKNOWN_IDENTIFIER), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.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&&) @ 0x000000001404b3b9 4. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3771: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000001401b849 5. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3980: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000014018e31 6. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:2925: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000001402fcbd 7. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3838: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000014019a9e 8. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:209: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000001401270e 9. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000014011fce 10. /build/src/Planner/Utils.cpp:458: DB::buildFilterInfo(std::shared_ptr, std::shared_ptr const&, std::shared_ptr&, std::unordered_set, std::equal_to, std::allocator>) @ 0x0000000013fe8bcf 11. /build/src/Planner/PlannerJoinTree.cpp:535: DB::(anonymous namespace)::buildQueryPlanForTableExpression(std::shared_ptr, std::shared_ptr const&, DB::SelectQueryInfo const&, DB::SelectQueryOptions const&, std::shared_ptr&, bool, bool) @ 0x00000000149956d3 12. /build/src/Planner/PlannerJoinTree.cpp:2252: DB::buildJoinTreeQueryPlan(std::shared_ptr const&, DB::SelectQueryInfo const&, DB::SelectQueryOptions&, std::unordered_set, std::equal_to, std::allocator> const&, std::shared_ptr&) @ 0x000000001498e109 13. /build/src/Planner/Planner.cpp:1553: DB::Planner::buildPlanForQueryNode() @ 0x0000000014979dae 14. /build/src/Planner/Planner.cpp:1308: DB::Planner::buildQueryPlanIfNeeded() @ 0x000000001497685c 15. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:255: DB::InterpreterSelectQueryAnalyzer::getQueryPlan() @ 0x000000001497476d 16. /build/src/Interpreters/executeQuery.cpp:1405: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88806 17. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 18. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 19. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 20. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 21. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 22. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 23. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 24. ? @ 0x00007fbc6213eac3 25. ? @ 0x00007fbc621d0850 2025.07.28 11:54:18.874546 [ 17557 ] {043e89ce-6f75-4534-9d05-c83b76ed7c51} executeQuery: Code: 1. DB::Exception: Resolved identifier 'item_id' in parent scope to expression 'l.item_id' with correlated column 'item_id'. In scope SELECT item_id FROM t1. (UNSUPPORTED_METHOD) (version 25.3.6.10636.altinitytest (altinity build)) (from [::1]:45974) (comment: 03255_parallel_replicas_join_algo_and_analyzer_4.sh) (query 5, line 7) (in query: --SELECT '----- enable_parallel_replicas=1 prefer_local_plan=1 parallel_replicas_prefer_local_join=0 -----'; SELECT sum(item_id) FROM ( SELECT item_id, price_sold FROM t ) AS l LEFT JOIN ( SELECT item_id FROM t1 ) AS r ON l.item_id = r.item_id GROUP BY price_sold ORDER BY price_sold ;), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/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 const&, String&&) @ 0x000000001404a1eb 4. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:1382: DB::QueryAnalyzer::tryResolveIdentifierInParentScopes(DB::IdentifierLookup const&, DB::IdentifierResolveScope&, DB::IdentifierResolveContext) @ 0x000000001402a8cc 5. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:1544: DB::QueryAnalyzer::tryResolveIdentifier(DB::IdentifierLookup const&, DB::IdentifierResolveScope&, DB::IdentifierResolveContext) @ 0x00000000140298dd 6. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3692: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000001401a2b4 7. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3980: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000014018e31 8. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:4304: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000014042fa7 9. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5605: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000014013749 10. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3870: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x00000000140199de 11. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5334: DB::QueryAnalyzer::resolveQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&) @ 0x00000000140454b0 12. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5142: DB::QueryAnalyzer::resolveJoin(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&) @ 0x0000000014046de9 13. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5361: DB::QueryAnalyzer::resolveQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&) @ 0x00000000140452d6 14. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5597: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000140136f0 15. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000140127f9 16. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000014011fce 17. /build/src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000001406ce8a 18. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000014973b42 19. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000001497268d 20. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000014974d24 21. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001492924b 22. /build/src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88641 23. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 24. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 25. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 26. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 27. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 28. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 29. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 30. ? @ 0x00007fbc6213eac3 31. ? @ 0x00007fbc621d0850 2025.07.28 11:54:18.909730 [ 17557 ] {} TCPHandler: Code: 1. DB::Exception: Resolved identifier 'item_id' in parent scope to expression 'l.item_id' with correlated column 'item_id'. In scope SELECT item_id FROM t1. (UNSUPPORTED_METHOD), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/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 const&, String&&) @ 0x000000001404a1eb 4. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:1382: DB::QueryAnalyzer::tryResolveIdentifierInParentScopes(DB::IdentifierLookup const&, DB::IdentifierResolveScope&, DB::IdentifierResolveContext) @ 0x000000001402a8cc 5. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:1544: DB::QueryAnalyzer::tryResolveIdentifier(DB::IdentifierLookup const&, DB::IdentifierResolveScope&, DB::IdentifierResolveContext) @ 0x00000000140298dd 6. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3692: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000001401a2b4 7. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3980: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000014018e31 8. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:4304: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000014042fa7 9. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5605: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000014013749 10. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3870: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x00000000140199de 11. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5334: DB::QueryAnalyzer::resolveQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&) @ 0x00000000140454b0 12. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5142: DB::QueryAnalyzer::resolveJoin(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&) @ 0x0000000014046de9 13. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5361: DB::QueryAnalyzer::resolveQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&) @ 0x00000000140452d6 14. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5597: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000140136f0 15. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000140127f9 16. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000014011fce 17. /build/src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000001406ce8a 18. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000014973b42 19. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000001497268d 20. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000014974d24 21. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001492924b 22. /build/src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88641 23. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 24. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 25. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 26. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 27. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 28. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 29. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 30. ? @ 0x00007fbc6213eac3 31. ? @ 0x00007fbc621d0850 2025.07.28 11:54:19.326322 [ 3974 ] {} test_13.rmt2 (7f9b740d-015c-470e-8cc6-8ba33be0dc63): auto DB::StorageReplicatedMergeTree::processQueueEntry(ReplicatedMergeTreeQueue::SelectedEntryPtr)::(anonymous class)::operator()(LogEntryPtr &) const: Code: 86. DB::HTTPException: Received error from remote server http://146b4357c08d:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Ftest%2F01165%2Ftest_13%2Frmt%2Freplicas%2F1&part=20250728_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.6.10636.altinitytest (altinity build)) '. (RECEIVED_ERROR_FROM_REMOTE_IO_SERVER), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.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 const&, int&&, String const&, unsigned long&&, String const&) @ 0x000000000feda8d9 4. /build/src/IO/HTTPCommon.cpp:104: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x000000000feda6e2 5. /build/src/IO/HTTPCommon.cpp:93: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x000000000feda537 6. /build/src/IO/ReadWriteBufferFromHTTP.cpp:277: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x000000001184a4c4 7. /build/src/IO/ReadWriteBufferFromHTTP.cpp:285: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x000000001184a615 8. /build/src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x000000001184ae59 9. /build/src/IO/ReadWriteBufferFromHTTP.cpp:472: void std::__function::__policy_invoker::__call_impl[abi:se190107]>(std::__function::__policy_storage const*) @ 0x000000001184cedd 10. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001184858b 11. /build/src/IO/ReadWriteBufferFromHTTP.cpp:465: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x000000001184bf0b 12. /build/src/IO/ReadBuffer.h:60: DB::ReadBuffer::next() @ 0x000000000a148c7b 13. /build/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) @ 0x0000000011849fb2 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]>&)>&, 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&) @ 0x0000000011841980 15. /build/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) @ 0x000000001621208e 16. /build/src/Storages/StorageReplicatedMergeTree.cpp:5228: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl[abi:se190107] const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000015f9a5fe 17. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000015ed8bfd 18. /build/src/Storages/StorageReplicatedMergeTree.cpp:2514: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x0000000015ec9aab 19. /build/src/Storages/StorageReplicatedMergeTree.cpp:2349: DB::StorageReplicatedMergeTree::executeLogEntry(DB::ReplicatedMergeTreeLogEntry&) @ 0x0000000015eba91b 20. /build/src/Storages/StorageReplicatedMergeTree.cpp:3876: bool std::__function::__policy_invoker&)>::__call_impl[abi:se190107])::$_1, bool (std::shared_ptr&)>>(std::__function::__policy_storage const*, std::shared_ptr&) @ 0x0000000015f9837e 21. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000165d6fc3 22. /build/src/Storages/StorageReplicatedMergeTree.cpp:3872: DB::StorageReplicatedMergeTree::processQueueEntry(std::shared_ptr) @ 0x0000000015efc18a 23. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001624c1b2 24. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000162f9c70 25. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x00000000162fa55a 26. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc6653 27. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000000fccc4c3 28. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc3d92 29. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fcca080 30. ? @ 0x00007fbc6213eac3 31. ? @ 0x00007fbc621d0850 (version 25.3.6.10636.altinitytest (altinity build)) 2025.07.28 11:54:19.791504 [ 11826 ] {8153f7e5-e893-4ad4-a2bb-53f57da49086} executeQuery: Code: 47. DB::Exception: Unknown expression identifier `x` in scope SELECT x FROM system.numbers LIMIT 1. (UNKNOWN_IDENTIFIER) (version 25.3.6.10636.altinitytest (altinity build)) (from [::1]:45962) (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. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.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&&) @ 0x000000001404b3b9 4. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3771: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000001401b849 5. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3980: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000014018e31 6. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:4304: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000014042fa7 7. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5605: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000014013749 8. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000140127f9 9. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000014011fce 10. /build/src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000001406ce8a 11. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000014973b42 12. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000001497268d 13. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000014974d24 14. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001492924b 15. /build/src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88641 16. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 17. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 18. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 19. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 20. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 21. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 22. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 23. ? @ 0x00007fbc6213eac3 24. ? @ 0x00007fbc621d0850 2025.07.28 11:54:19.797282 [ 11826 ] {} 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. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.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&&) @ 0x000000001404b3b9 4. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3771: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000001401b849 5. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3980: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000014018e31 6. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:4304: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000014042fa7 7. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5605: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000014013749 8. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000140127f9 9. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000014011fce 10. /build/src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000001406ce8a 11. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000014973b42 12. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000001497268d 13. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000014974d24 14. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001492924b 15. /build/src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88641 16. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 17. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 18. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 19. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 20. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 21. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 22. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 23. ? @ 0x00007fbc6213eac3 24. ? @ 0x00007fbc621d0850 2025.07.28 11:54:19.929718 [ 11826 ] {f6429af9-82ad-4827-bc58-4b4237620409} executeQuery: Code: 47. DB::Exception: Unknown expression identifier `x` in scope SELECT x, number FROM system.numbers LIMIT 1. (UNKNOWN_IDENTIFIER) (version 25.3.6.10636.altinitytest (altinity build)) (from [::1]:45962) (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. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.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&&) @ 0x000000001404b3b9 4. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3771: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000001401b849 5. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3980: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000014018e31 6. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:4304: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000014042fa7 7. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5605: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000014013749 8. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000140127f9 9. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000014011fce 10. /build/src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000001406ce8a 11. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000014973b42 12. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000001497268d 13. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000014974d24 14. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001492924b 15. /build/src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88641 16. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 17. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 18. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 19. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 20. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 21. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 22. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 23. ? @ 0x00007fbc6213eac3 24. ? @ 0x00007fbc621d0850 2025.07.28 11:54:19.933126 [ 11826 ] {} 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. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.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&&) @ 0x000000001404b3b9 4. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3771: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000001401b849 5. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3980: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000014018e31 6. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:4304: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000014042fa7 7. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5605: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000014013749 8. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000140127f9 9. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000014011fce 10. /build/src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000001406ce8a 11. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000014973b42 12. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000001497268d 13. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000014974d24 14. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001492924b 15. /build/src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88641 16. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 17. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 18. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 19. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 20. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 21. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 22. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 23. ? @ 0x00007fbc6213eac3 24. ? @ 0x00007fbc621d0850 2025.07.28 11:54:19.952988 [ 11826 ] {95fa41fe-9b65-410f-9c07-6e8f4e5169ed} executeQuery: Code: 60. DB::Exception: Unknown table expression identifier 'system.number' in scope SELECT * FROM system.number LIMIT 1. (UNKNOWN_TABLE) (version 25.3.6.10636.altinitytest (altinity build)) (from [::1]:45962) (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. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x000000000a6a1e2b 4. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:4372: DB::QueryAnalyzer::initializeQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000001404440b 5. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5594: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000140135fb 6. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000140127f9 7. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000014011fce 8. /build/src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000001406ce8a 9. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000014973b42 10. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000001497268d 11. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000014974d24 12. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001492924b 13. /build/src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88641 14. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 15. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 16. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 17. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 18. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 19. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 20. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 21. ? @ 0x00007fbc6213eac3 22. ? @ 0x00007fbc621d0850 2025.07.28 11:54:19.973897 [ 11826 ] {} 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. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x000000000a6a1e2b 4. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:4372: DB::QueryAnalyzer::initializeQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000001404440b 5. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5594: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000140135fb 6. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000140127f9 7. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000014011fce 8. /build/src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000001406ce8a 9. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000014973b42 10. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000001497268d 11. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000014974d24 12. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001492924b 13. /build/src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88641 14. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 15. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 16. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 17. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 18. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 19. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 20. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 21. ? @ 0x00007fbc6213eac3 22. ? @ 0x00007fbc621d0850 2025.07.28 11:54:20.060700 [ 11826 ] {760775b8-1c98-45b3-8477-7e761ac62e0d} executeQuery: Code: 60. DB::Exception: Unknown table expression identifier 'system' in scope SELECT * FROM system LIMIT 1. (UNKNOWN_TABLE) (version 25.3.6.10636.altinitytest (altinity build)) (from [::1]:45962) (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. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x000000000a6a1e2b 4. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:4372: DB::QueryAnalyzer::initializeQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000001404440b 5. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5594: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000140135fb 6. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000140127f9 7. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000014011fce 8. /build/src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000001406ce8a 9. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000014973b42 10. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000001497268d 11. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000014974d24 12. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001492924b 13. /build/src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88641 14. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 15. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 16. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 17. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 18. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 19. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 20. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 21. ? @ 0x00007fbc6213eac3 22. ? @ 0x00007fbc621d0850 2025.07.28 11:54:20.065908 [ 11826 ] {} 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. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x000000000a6a1e2b 4. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:4372: DB::QueryAnalyzer::initializeQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000001404440b 5. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5594: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000140135fb 6. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000140127f9 7. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000014011fce 8. /build/src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000001406ce8a 9. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000014973b42 10. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000001497268d 11. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000014974d24 12. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001492924b 13. /build/src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88641 14. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 15. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 16. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 17. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 18. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 19. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 20. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 21. ? @ 0x00007fbc6213eac3 22. ? @ 0x00007fbc621d0850 2025.07.28 11:54:20.072760 [ 3961 ] {} test_13.rmt2 (7f9b740d-015c-470e-8cc6-8ba33be0dc63): auto DB::StorageReplicatedMergeTree::processQueueEntry(ReplicatedMergeTreeQueue::SelectedEntryPtr)::(anonymous class)::operator()(LogEntryPtr &) const: Code: 86. DB::HTTPException: Received error from remote server http://146b4357c08d:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Ftest%2F01165%2Ftest_13%2Frmt%2Freplicas%2F1&part=20250728_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.6.10636.altinitytest (altinity build)) '. (RECEIVED_ERROR_FROM_REMOTE_IO_SERVER), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.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 const&, int&&, String const&, unsigned long&&, String const&) @ 0x000000000feda8d9 4. /build/src/IO/HTTPCommon.cpp:104: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x000000000feda6e2 5. /build/src/IO/HTTPCommon.cpp:93: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x000000000feda537 6. /build/src/IO/ReadWriteBufferFromHTTP.cpp:277: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x000000001184a4c4 7. /build/src/IO/ReadWriteBufferFromHTTP.cpp:285: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x000000001184a615 8. /build/src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x000000001184ae59 9. /build/src/IO/ReadWriteBufferFromHTTP.cpp:472: void std::__function::__policy_invoker::__call_impl[abi:se190107]>(std::__function::__policy_storage const*) @ 0x000000001184cedd 10. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001184858b 11. /build/src/IO/ReadWriteBufferFromHTTP.cpp:465: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x000000001184bf0b 12. /build/src/IO/ReadBuffer.h:60: DB::ReadBuffer::next() @ 0x000000000a148c7b 13. /build/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) @ 0x0000000011849fb2 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]>&)>&, 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&) @ 0x0000000011841980 15. /build/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) @ 0x000000001621208e 16. /build/src/Storages/StorageReplicatedMergeTree.cpp:5228: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl[abi:se190107] const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000015f9a5fe 17. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000015ed8bfd 18. /build/src/Storages/StorageReplicatedMergeTree.cpp:2514: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x0000000015ec9aab 19. /build/src/Storages/StorageReplicatedMergeTree.cpp:2349: DB::StorageReplicatedMergeTree::executeLogEntry(DB::ReplicatedMergeTreeLogEntry&) @ 0x0000000015eba91b 20. /build/src/Storages/StorageReplicatedMergeTree.cpp:3876: bool std::__function::__policy_invoker&)>::__call_impl[abi:se190107])::$_1, bool (std::shared_ptr&)>>(std::__function::__policy_storage const*, std::shared_ptr&) @ 0x0000000015f9837e 21. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000165d6fc3 22. /build/src/Storages/StorageReplicatedMergeTree.cpp:3872: DB::StorageReplicatedMergeTree::processQueueEntry(std::shared_ptr) @ 0x0000000015efc18a 23. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001624c1b2 24. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000162f9c70 25. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x00000000162fa55a 26. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc6653 27. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000000fccc4c3 28. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc3d92 29. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fcca080 30. ? @ 0x00007fbc6213eac3 31. ? @ 0x00007fbc621d0850 (version 25.3.6.10636.altinitytest (altinity build)) 2025.07.28 11:54:20.102615 [ 11826 ] {84a3a642-46ff-4b92-92bf-7a27ea953558} executeQuery: Code: 60. DB::Exception: Unknown table expression identifier 'numbers' in scope SELECT * FROM numbers LIMIT 1. (UNKNOWN_TABLE) (version 25.3.6.10636.altinitytest (altinity build)) (from [::1]:45962) (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. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x000000000a6a1e2b 4. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:4372: DB::QueryAnalyzer::initializeQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000001404440b 5. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5594: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000140135fb 6. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000140127f9 7. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000014011fce 8. /build/src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000001406ce8a 9. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000014973b42 10. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000001497268d 11. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000014974d24 12. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001492924b 13. /build/src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88641 14. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 15. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 16. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 17. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 18. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 19. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 20. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 21. ? @ 0x00007fbc6213eac3 22. ? @ 0x00007fbc621d0850 2025.07.28 11:54:20.112325 [ 11826 ] {} 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. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x000000000a6a1e2b 4. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:4372: DB::QueryAnalyzer::initializeQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000001404440b 5. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5594: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000140135fb 6. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000140127f9 7. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000014011fce 8. /build/src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000001406ce8a 9. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000014973b42 10. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000001497268d 11. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000014974d24 12. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001492924b 13. /build/src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88641 14. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 15. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 16. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 17. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 18. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 19. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 20. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 21. ? @ 0x00007fbc6213eac3 22. ? @ 0x00007fbc621d0850 2025.07.28 11:54:20.209498 [ 11826 ] {bb531428-08d7-4748-87c1-fc350398e6fc} 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.6.10636.altinitytest (altinity build)) (from [::1]:45962) (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. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.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&&) @ 0x000000001404b3b9 4. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3771: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000001401b849 5. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3980: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000014018e31 6. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:4304: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000014042fa7 7. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5605: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000014013749 8. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000140127f9 9. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000014011fce 10. /build/src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000001406ce8a 11. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000014973b42 12. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000001497268d 13. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000014974d24 14. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001492924b 15. /build/src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88641 16. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 17. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 18. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 19. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 20. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 21. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 22. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 23. ? @ 0x00007fbc6213eac3 24. ? @ 0x00007fbc621d0850 2025.07.28 11:54:20.214790 [ 11826 ] {} 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. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.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&&) @ 0x000000001404b3b9 4. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3771: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000001401b849 5. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3980: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000014018e31 6. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:4304: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000014042fa7 7. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5605: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000014013749 8. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000140127f9 9. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000014011fce 10. /build/src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000001406ce8a 11. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000014973b42 12. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000001497268d 13. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000014974d24 14. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001492924b 15. /build/src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88641 16. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 17. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 18. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 19. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 20. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 21. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 22. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 23. ? @ 0x00007fbc6213eac3 24. ? @ 0x00007fbc621d0850 2025.07.28 11:54:20.420577 [ 17255 ] {} 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. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception>&, String>(int, FormatStringHelperImpl>&>::type, std::type_identity::type>, std::basic_string_view>&, String&&) @ 0x000000001385a5eb 4. /build/src/Access/SettingsConstraints.cpp:376: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000013859b18 5. /build/src/Access/SettingsConstraints.cpp:300: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000013858faf 6. /build/src/Access/SettingsConstraints.cpp:209: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000013859223 7. /build/src/Interpreters/Context.cpp:2690: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000014436134 8. /build/src/Interpreters/Context.cpp:2729: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x000000001443662b 9. /build/src/Server/HTTPHandler.cpp:457: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000001686d165 10. /build/src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x0000000016870807 11. /build/src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x0000000016907e99 12. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 13. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 14. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 15. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 16. ? @ 0x00007fbc6213eac3 17. ? @ 0x00007fbc621d0850 (version 25.3.6.10636.altinitytest (altinity build)) 2025.07.28 11:54:20.529305 [ 5879 ] {eaab7cf0-15c2-4bd9-8d29-9bb6efdbc957} executeQuery: Code: 36. DB::Exception: Cannot drop column x because it's affected by mutation with ID '0000000001' which is not finished yet. Wait this mutation, or KILL it with command "KILL MUTATION WHERE mutation_id = '0000000001'". (BAD_ARGUMENTS) (version 25.3.6.10636.altinitytest (altinity build)) (from [::1]:45922) (comment: 02597_column_update_and_replication.sql) (query 8, line 24) (in query: ALTER TABLE test DROP COLUMN x SETTINGS mutations_sync = 2;), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/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 const&, String const&) @ 0x00000000163a066b 4. /build/src/Storages/MergeTree/MergeTreeData.cpp:8539: DB::MergeTreeData::checkDropCommandDoesntAffectInProgressMutations(DB::AlterCommand const&, std::map, std::allocator>> const&, std::shared_ptr) const::$_0::operator()(String const&, String const&, String const&) const @ 0x000000001638015f 5. /build/src/Storages/MergeTree/MergeTreeData.cpp:8580: DB::MergeTreeData::checkDropCommandDoesntAffectInProgressMutations(DB::AlterCommand const&, std::map, std::allocator>> const&, std::shared_ptr) const @ 0x000000001633a389 6. /build/src/Storages/MergeTree/MergeTreeData.cpp:3639: DB::MergeTreeData::checkAlterIsPossible(DB::AlterCommands const&, std::shared_ptr) const @ 0x0000000016336252 7. /build/src/Interpreters/InterpreterAlterQuery.cpp:215: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x00000000148deab3 8. /build/src/Interpreters/InterpreterAlterQuery.cpp:77: DB::InterpreterAlterQuery::execute() @ 0x00000000148dcb0d 9. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88dc9 10. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 11. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 12. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 13. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 14. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 16. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 17. ? @ 0x00007fbc6213eac3 18. ? @ 0x00007fbc621d0850 2025.07.28 11:54:20.533449 [ 3944 ] {} 7de53544-01da-4656-ac71-e7ce3a791c9f::all_1_1_0_2 (MutateFromLogEntryTask): virtual bool DB::ReplicatedMergeMutateTaskBase::executeStep(): Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(1 :: 1) -> throwIf(1) UInt8 : 3'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x000000000a06b56b 4. /build/src/Functions/throwIf.cpp:153: DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000e8193b5 5. /build/src/Functions/IFunctionAdaptors.cpp:10: DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000012d995fa 6. /build/src/Functions/IFunction.cpp:353: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d93b52 7. /build/src/Functions/IFunction.cpp:420: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d95059 8. /build/src/Functions/IFunction.cpp:498: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d95c72 9. /build/src/Interpreters/ExpressionActions.cpp:636: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x00000000145176f3 10. /build/src/Processors/Transforms/ExpressionTransform.cpp:25: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x0000000016c0b34c 11. /build/src/Processors/ISimpleTransform.h:33: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000011a9a453 12. /build/src/Processors/ISimpleTransform.cpp:89: DB::ISimpleTransform::work() @ 0x000000001699fca0 13. /build/src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x00000000169bd00f 14. /build/src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x00000000169b2105 15. /build/src/Processors/Executors/PipelineExecutor.cpp:170: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x00000000169b16a7 16. /build/src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x00000000169c081c 17. /build/src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x00000000169c0978 18. /build/src/Storages/MergeTree/MutateTask.cpp:1247: DB::PartMergerWriter::mutateOriginalPartAndPrepareProjections() @ 0x0000000016528eae 19. /build/src/Storages/MergeTree/MutateTask.cpp:1162: DB::PartMergerWriter::execute() @ 0x0000000016540eb4 20. /build/src/Storages/MergeTree/MutateTask.cpp:1741: DB::MutateSomePartColumnsTask::executeStep() @ 0x0000000016541736 21. /build/src/Storages/MergeTree/MutateTask.cpp:2113: DB::MutateTask::execute() @ 0x000000001652b32f 22. /build/src/Storages/MergeTree/ReplicatedMergeMutateTaskBase.cpp:217: DB::ReplicatedMergeMutateTaskBase::executeImpl() @ 0x000000001658a0dd 23. /build/src/Storages/MergeTree/ReplicatedMergeMutateTaskBase.cpp:56: DB::ReplicatedMergeMutateTaskBase::executeStep() @ 0x0000000016588d76 24. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000162fc850 25. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x00000000162fd193 26. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc6653 27. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000000fccc4c3 28. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc3d92 29. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fcca080 30. ? @ 0x00007fbc6213eac3 31. ? @ 0x00007fbc621d0850 (version 25.3.6.10636.altinitytest (altinity build)) 2025.07.28 11:54:20.534825 [ 3944 ] {} MergeTreeBackgroundExecutor: Exception while executing background task {7de53544-01da-4656-ac71-e7ce3a791c9f::all_1_1_0_2}: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(1 :: 1) -> throwIf(1) UInt8 : 3'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x000000000a06b56b 4. /build/src/Functions/throwIf.cpp:153: DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000e8193b5 5. /build/src/Functions/IFunctionAdaptors.cpp:10: DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000012d995fa 6. /build/src/Functions/IFunction.cpp:353: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d93b52 7. /build/src/Functions/IFunction.cpp:420: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d95059 8. /build/src/Functions/IFunction.cpp:498: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d95c72 9. /build/src/Interpreters/ExpressionActions.cpp:636: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x00000000145176f3 10. /build/src/Processors/Transforms/ExpressionTransform.cpp:25: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x0000000016c0b34c 11. /build/src/Processors/ISimpleTransform.h:33: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000011a9a453 12. /build/src/Processors/ISimpleTransform.cpp:89: DB::ISimpleTransform::work() @ 0x000000001699fca0 13. /build/src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x00000000169bd00f 14. /build/src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x00000000169b2105 15. /build/src/Processors/Executors/PipelineExecutor.cpp:170: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x00000000169b16a7 16. /build/src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x00000000169c081c 17. /build/src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x00000000169c0978 18. /build/src/Storages/MergeTree/MutateTask.cpp:1247: DB::PartMergerWriter::mutateOriginalPartAndPrepareProjections() @ 0x0000000016528eae 19. /build/src/Storages/MergeTree/MutateTask.cpp:1162: DB::PartMergerWriter::execute() @ 0x0000000016540eb4 20. /build/src/Storages/MergeTree/MutateTask.cpp:1741: DB::MutateSomePartColumnsTask::executeStep() @ 0x0000000016541736 21. /build/src/Storages/MergeTree/MutateTask.cpp:2113: DB::MutateTask::execute() @ 0x000000001652b32f 22. /build/src/Storages/MergeTree/ReplicatedMergeMutateTaskBase.cpp:217: DB::ReplicatedMergeMutateTaskBase::executeImpl() @ 0x000000001658a0dd 23. /build/src/Storages/MergeTree/ReplicatedMergeMutateTaskBase.cpp:56: DB::ReplicatedMergeMutateTaskBase::executeStep() @ 0x0000000016588d76 24. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000162fc850 25. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x00000000162fd193 26. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc6653 27. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000000fccc4c3 28. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc3d92 29. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fcca080 30. ? @ 0x00007fbc6213eac3 31. ? @ 0x00007fbc621d0850 (version 25.3.6.10636.altinitytest (altinity build)) 2025.07.28 11:54:20.538763 [ 5879 ] {} TCPHandler: Code: 36. DB::Exception: Cannot drop column x because it's affected by mutation with ID '0000000001' which is not finished yet. Wait this mutation, or KILL it with command "KILL MUTATION WHERE mutation_id = '0000000001'". (BAD_ARGUMENTS), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/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 const&, String const&) @ 0x00000000163a066b 4. /build/src/Storages/MergeTree/MergeTreeData.cpp:8539: DB::MergeTreeData::checkDropCommandDoesntAffectInProgressMutations(DB::AlterCommand const&, std::map, std::allocator>> const&, std::shared_ptr) const::$_0::operator()(String const&, String const&, String const&) const @ 0x000000001638015f 5. /build/src/Storages/MergeTree/MergeTreeData.cpp:8580: DB::MergeTreeData::checkDropCommandDoesntAffectInProgressMutations(DB::AlterCommand const&, std::map, std::allocator>> const&, std::shared_ptr) const @ 0x000000001633a389 6. /build/src/Storages/MergeTree/MergeTreeData.cpp:3639: DB::MergeTreeData::checkAlterIsPossible(DB::AlterCommands const&, std::shared_ptr) const @ 0x0000000016336252 7. /build/src/Interpreters/InterpreterAlterQuery.cpp:215: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x00000000148deab3 8. /build/src/Interpreters/InterpreterAlterQuery.cpp:77: DB::InterpreterAlterQuery::execute() @ 0x00000000148dcb0d 9. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88dc9 10. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 11. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 12. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 13. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 14. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 16. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 17. ? @ 0x00007fbc6213eac3 18. ? @ 0x00007fbc621d0850 2025.07.28 11:54:20.540314 [ 3945 ] {} 7de53544-01da-4656-ac71-e7ce3a791c9f::all_0_0_0_2 (MutateFromLogEntryTask): virtual bool DB::ReplicatedMergeMutateTaskBase::executeStep(): Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(1 :: 1) -> throwIf(1) UInt8 : 3'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x000000000a06b56b 4. /build/src/Functions/throwIf.cpp:153: DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000e8193b5 5. /build/src/Functions/IFunctionAdaptors.cpp:10: DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000012d995fa 6. /build/src/Functions/IFunction.cpp:353: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d93b52 7. /build/src/Functions/IFunction.cpp:420: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d95059 8. /build/src/Functions/IFunction.cpp:498: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d95c72 9. /build/src/Interpreters/ExpressionActions.cpp:636: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x00000000145176f3 10. /build/src/Processors/Transforms/ExpressionTransform.cpp:25: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x0000000016c0b34c 11. /build/src/Processors/ISimpleTransform.h:33: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000011a9a453 12. /build/src/Processors/ISimpleTransform.cpp:89: DB::ISimpleTransform::work() @ 0x000000001699fca0 13. /build/src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x00000000169bd00f 14. /build/src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x00000000169b2105 15. /build/src/Processors/Executors/PipelineExecutor.cpp:170: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x00000000169b16a7 16. /build/src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x00000000169c081c 17. /build/src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x00000000169c0978 18. /build/src/Storages/MergeTree/MutateTask.cpp:1247: DB::PartMergerWriter::mutateOriginalPartAndPrepareProjections() @ 0x0000000016528eae 19. /build/src/Storages/MergeTree/MutateTask.cpp:1162: DB::PartMergerWriter::execute() @ 0x0000000016540eb4 20. /build/src/Storages/MergeTree/MutateTask.cpp:1741: DB::MutateSomePartColumnsTask::executeStep() @ 0x0000000016541736 21. /build/src/Storages/MergeTree/MutateTask.cpp:2113: DB::MutateTask::execute() @ 0x000000001652b32f 22. /build/src/Storages/MergeTree/ReplicatedMergeMutateTaskBase.cpp:217: DB::ReplicatedMergeMutateTaskBase::executeImpl() @ 0x000000001658a0dd 23. /build/src/Storages/MergeTree/ReplicatedMergeMutateTaskBase.cpp:56: DB::ReplicatedMergeMutateTaskBase::executeStep() @ 0x0000000016588d76 24. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000162fc850 25. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x00000000162fd193 26. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc6653 27. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000000fccc4c3 28. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc3d92 29. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fcca080 30. ? @ 0x00007fbc6213eac3 31. ? @ 0x00007fbc621d0850 (version 25.3.6.10636.altinitytest (altinity build)) 2025.07.28 11:54:20.541564 [ 3945 ] {} MergeTreeBackgroundExecutor: Exception while executing background task {7de53544-01da-4656-ac71-e7ce3a791c9f::all_0_0_0_2}: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(1 :: 1) -> throwIf(1) UInt8 : 3'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x000000000a06b56b 4. /build/src/Functions/throwIf.cpp:153: DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000e8193b5 5. /build/src/Functions/IFunctionAdaptors.cpp:10: DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000012d995fa 6. /build/src/Functions/IFunction.cpp:353: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d93b52 7. /build/src/Functions/IFunction.cpp:420: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d95059 8. /build/src/Functions/IFunction.cpp:498: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d95c72 9. /build/src/Interpreters/ExpressionActions.cpp:636: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x00000000145176f3 10. /build/src/Processors/Transforms/ExpressionTransform.cpp:25: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x0000000016c0b34c 11. /build/src/Processors/ISimpleTransform.h:33: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000011a9a453 12. /build/src/Processors/ISimpleTransform.cpp:89: DB::ISimpleTransform::work() @ 0x000000001699fca0 13. /build/src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x00000000169bd00f 14. /build/src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x00000000169b2105 15. /build/src/Processors/Executors/PipelineExecutor.cpp:170: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x00000000169b16a7 16. /build/src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x00000000169c081c 17. /build/src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x00000000169c0978 18. /build/src/Storages/MergeTree/MutateTask.cpp:1247: DB::PartMergerWriter::mutateOriginalPartAndPrepareProjections() @ 0x0000000016528eae 19. /build/src/Storages/MergeTree/MutateTask.cpp:1162: DB::PartMergerWriter::execute() @ 0x0000000016540eb4 20. /build/src/Storages/MergeTree/MutateTask.cpp:1741: DB::MutateSomePartColumnsTask::executeStep() @ 0x0000000016541736 21. /build/src/Storages/MergeTree/MutateTask.cpp:2113: DB::MutateTask::execute() @ 0x000000001652b32f 22. /build/src/Storages/MergeTree/ReplicatedMergeMutateTaskBase.cpp:217: DB::ReplicatedMergeMutateTaskBase::executeImpl() @ 0x000000001658a0dd 23. /build/src/Storages/MergeTree/ReplicatedMergeMutateTaskBase.cpp:56: DB::ReplicatedMergeMutateTaskBase::executeStep() @ 0x0000000016588d76 24. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000162fc850 25. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x00000000162fd193 26. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc6653 27. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000000fccc4c3 28. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc3d92 29. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fcca080 30. ? @ 0x00007fbc6213eac3 31. ? @ 0x00007fbc621d0850 (version 25.3.6.10636.altinitytest (altinity build)) 2025.07.28 11:54:20.745799 [ 3946 ] {} test_15.test (ReplicatedMergeTreeQueue): Mutation with version 2 not found in partition ID all (trying to mutate part all_0_0_0) 2025.07.28 11:54:20.747751 [ 3951 ] {} test_15.test (ReplicatedMergeTreeQueue): Mutation with version 2 not found in partition ID all (trying to mutate part all_1_1_0) 2025.07.28 11:54:21.157118 [ 3977 ] {} test_13.rmt2 (7f9b740d-015c-470e-8cc6-8ba33be0dc63): auto DB::StorageReplicatedMergeTree::processQueueEntry(ReplicatedMergeTreeQueue::SelectedEntryPtr)::(anonymous class)::operator()(LogEntryPtr &) const: Code: 86. DB::HTTPException: Received error from remote server http://146b4357c08d:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Ftest%2F01165%2Ftest_13%2Frmt%2Freplicas%2F1&part=20250728_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.6.10636.altinitytest (altinity build)) '. (RECEIVED_ERROR_FROM_REMOTE_IO_SERVER), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.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 const&, int&&, String const&, unsigned long&&, String const&) @ 0x000000000feda8d9 4. /build/src/IO/HTTPCommon.cpp:104: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x000000000feda6e2 5. /build/src/IO/HTTPCommon.cpp:93: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x000000000feda537 6. /build/src/IO/ReadWriteBufferFromHTTP.cpp:277: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x000000001184a4c4 7. /build/src/IO/ReadWriteBufferFromHTTP.cpp:285: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x000000001184a615 8. /build/src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x000000001184ae59 9. /build/src/IO/ReadWriteBufferFromHTTP.cpp:472: void std::__function::__policy_invoker::__call_impl[abi:se190107]>(std::__function::__policy_storage const*) @ 0x000000001184cedd 10. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001184858b 11. /build/src/IO/ReadWriteBufferFromHTTP.cpp:465: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x000000001184bf0b 12. /build/src/IO/ReadBuffer.h:60: DB::ReadBuffer::next() @ 0x000000000a148c7b 13. /build/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) @ 0x0000000011849fb2 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]>&)>&, 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&) @ 0x0000000011841980 15. /build/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) @ 0x000000001621208e 16. /build/src/Storages/StorageReplicatedMergeTree.cpp:5228: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl[abi:se190107] const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000015f9a5fe 17. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000015ed8bfd 18. /build/src/Storages/StorageReplicatedMergeTree.cpp:2514: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x0000000015ec9aab 19. /build/src/Storages/StorageReplicatedMergeTree.cpp:2349: DB::StorageReplicatedMergeTree::executeLogEntry(DB::ReplicatedMergeTreeLogEntry&) @ 0x0000000015eba91b 20. /build/src/Storages/StorageReplicatedMergeTree.cpp:3876: bool std::__function::__policy_invoker&)>::__call_impl[abi:se190107])::$_1, bool (std::shared_ptr&)>>(std::__function::__policy_storage const*, std::shared_ptr&) @ 0x0000000015f9837e 21. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000165d6fc3 22. /build/src/Storages/StorageReplicatedMergeTree.cpp:3872: DB::StorageReplicatedMergeTree::processQueueEntry(std::shared_ptr) @ 0x0000000015efc18a 23. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001624c1b2 24. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000162f9c70 25. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x00000000162fa55a 26. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc6653 27. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000000fccc4c3 28. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc3d92 29. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fcca080 30. ? @ 0x00007fbc6213eac3 31. ? @ 0x00007fbc621d0850 (version 25.3.6.10636.altinitytest (altinity build)) 2025.07.28 11:54:21.379499 [ 3964 ] {} test_13.rmt2 (7f9b740d-015c-470e-8cc6-8ba33be0dc63): auto DB::StorageReplicatedMergeTree::processQueueEntry(ReplicatedMergeTreeQueue::SelectedEntryPtr)::(anonymous class)::operator()(LogEntryPtr &) const: Code: 86. DB::HTTPException: Received error from remote server http://146b4357c08d:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Ftest%2F01165%2Ftest_13%2Frmt%2Freplicas%2F1&part=20250728_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.6.10636.altinitytest (altinity build)) '. (RECEIVED_ERROR_FROM_REMOTE_IO_SERVER), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.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 const&, int&&, String const&, unsigned long&&, String const&) @ 0x000000000feda8d9 4. /build/src/IO/HTTPCommon.cpp:104: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x000000000feda6e2 5. /build/src/IO/HTTPCommon.cpp:93: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x000000000feda537 6. /build/src/IO/ReadWriteBufferFromHTTP.cpp:277: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x000000001184a4c4 7. /build/src/IO/ReadWriteBufferFromHTTP.cpp:285: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x000000001184a615 8. /build/src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x000000001184ae59 9. /build/src/IO/ReadWriteBufferFromHTTP.cpp:472: void std::__function::__policy_invoker::__call_impl[abi:se190107]>(std::__function::__policy_storage const*) @ 0x000000001184cedd 10. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001184858b 11. /build/src/IO/ReadWriteBufferFromHTTP.cpp:465: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x000000001184bf0b 12. /build/src/IO/ReadBuffer.h:60: DB::ReadBuffer::next() @ 0x000000000a148c7b 13. /build/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) @ 0x0000000011849fb2 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]>&)>&, 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&) @ 0x0000000011841980 15. /build/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) @ 0x000000001621208e 16. /build/src/Storages/StorageReplicatedMergeTree.cpp:5228: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl[abi:se190107] const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000015f9a5fe 17. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000015ed8bfd 18. /build/src/Storages/StorageReplicatedMergeTree.cpp:2514: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x0000000015ec9aab 19. /build/src/Storages/StorageReplicatedMergeTree.cpp:2349: DB::StorageReplicatedMergeTree::executeLogEntry(DB::ReplicatedMergeTreeLogEntry&) @ 0x0000000015eba91b 20. /build/src/Storages/StorageReplicatedMergeTree.cpp:3876: bool std::__function::__policy_invoker&)>::__call_impl[abi:se190107])::$_1, bool (std::shared_ptr&)>>(std::__function::__policy_storage const*, std::shared_ptr&) @ 0x0000000015f9837e 21. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000165d6fc3 22. /build/src/Storages/StorageReplicatedMergeTree.cpp:3872: DB::StorageReplicatedMergeTree::processQueueEntry(std::shared_ptr) @ 0x0000000015efc18a 23. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001624c1b2 24. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000162f9c70 25. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x00000000162fa55a 26. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc6653 27. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000000fccc4c3 28. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc3d92 29. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fcca080 30. ? @ 0x00007fbc6213eac3 31. ? @ 0x00007fbc621d0850 (version 25.3.6.10636.altinitytest (altinity build)) 2025.07.28 11:54:21.762603 [ 3966 ] {} test_13.rmt2 (7f9b740d-015c-470e-8cc6-8ba33be0dc63): auto DB::StorageReplicatedMergeTree::processQueueEntry(ReplicatedMergeTreeQueue::SelectedEntryPtr)::(anonymous class)::operator()(LogEntryPtr &) const: Code: 86. DB::HTTPException: Received error from remote server http://146b4357c08d:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Ftest%2F01165%2Ftest_13%2Frmt%2Freplicas%2F1&part=20250728_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.6.10636.altinitytest (altinity build)) '. (RECEIVED_ERROR_FROM_REMOTE_IO_SERVER), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.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 const&, int&&, String const&, unsigned long&&, String const&) @ 0x000000000feda8d9 4. /build/src/IO/HTTPCommon.cpp:104: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x000000000feda6e2 5. /build/src/IO/HTTPCommon.cpp:93: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x000000000feda537 6. /build/src/IO/ReadWriteBufferFromHTTP.cpp:277: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x000000001184a4c4 7. /build/src/IO/ReadWriteBufferFromHTTP.cpp:285: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x000000001184a615 8. /build/src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x000000001184ae59 9. /build/src/IO/ReadWriteBufferFromHTTP.cpp:472: void std::__function::__policy_invoker::__call_impl[abi:se190107]>(std::__function::__policy_storage const*) @ 0x000000001184cedd 10. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001184858b 11. /build/src/IO/ReadWriteBufferFromHTTP.cpp:465: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x000000001184bf0b 12. /build/src/IO/ReadBuffer.h:60: DB::ReadBuffer::next() @ 0x000000000a148c7b 13. /build/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) @ 0x0000000011849fb2 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]>&)>&, 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&) @ 0x0000000011841980 15. /build/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) @ 0x000000001621208e 16. /build/src/Storages/StorageReplicatedMergeTree.cpp:5228: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl[abi:se190107] const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000015f9a5fe 17. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000015ed8bfd 18. /build/src/Storages/StorageReplicatedMergeTree.cpp:2514: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x0000000015ec9aab 19. /build/src/Storages/StorageReplicatedMergeTree.cpp:2349: DB::StorageReplicatedMergeTree::executeLogEntry(DB::ReplicatedMergeTreeLogEntry&) @ 0x0000000015eba91b 20. /build/src/Storages/StorageReplicatedMergeTree.cpp:3876: bool std::__function::__policy_invoker&)>::__call_impl[abi:se190107])::$_1, bool (std::shared_ptr&)>>(std::__function::__policy_storage const*, std::shared_ptr&) @ 0x0000000015f9837e 21. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000165d6fc3 22. /build/src/Storages/StorageReplicatedMergeTree.cpp:3872: DB::StorageReplicatedMergeTree::processQueueEntry(std::shared_ptr) @ 0x0000000015efc18a 23. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001624c1b2 24. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000162f9c70 25. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x00000000162fa55a 26. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc6653 27. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000000fccc4c3 28. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc3d92 29. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fcca080 30. ? @ 0x00007fbc6213eac3 31. ? @ 0x00007fbc621d0850 (version 25.3.6.10636.altinitytest (altinity build)) 2025.07.28 11:54:21.917338 [ 17251 ] {e7842f33-1305-49bf-b98d-aea25339bbef} executeQuery: Code: 153. DB::Exception: Division by zero: while executing 'FUNCTION modulo(1_UInt8 :: 1, modulo(plus(__table1.number, 500_UInt16), 1000_UInt16) :: 2) -> modulo(1_UInt8, modulo(plus(__table1.number, 500_UInt16), 1000_UInt16)) UInt16 : 3'. (ILLEGAL_DIVISION) (version 25.3.6.10636.altinitytest (altinity build)) (from [::1]:45902) (comment: 00093_union_race_conditions_4.sh) (query 1, line 1) (in query: SELECT 1 % ((number + 500) % 1000) FROM numbers_mt(1000);), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000000a074fcb 4. /build/src/Functions/DivisionUtils.h:26: void DB::impl_::BinaryOperation, unsigned short>::process<(DB::impl_::OpCase)1>(char8_t const*, unsigned short const*, unsigned short*, unsigned long, DB::PODArray, 63ul, 64ul> const*) @ 0x000000000d184621 5. /build/src/Functions/FunctionBinaryArithmetic.h:2338: COW::immutable_ptr DB::FunctionBinaryArithmetic::executeNumeric, DB::DataTypeNumber>(std::vector> const&, DB::DataTypeNumber const&, DB::DataTypeNumber const&, DB::PODArray, 63ul, 64ul> const*) const @ 0x000000000d3a6416 6. /build/src/Functions/FunctionBinaryArithmetic.h:2508: 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&&) @ 0x000000000d3a4a68 7. /build/src/Functions/FunctionBinaryArithmetic.h:846: 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&&) @ 0x000000000d3a3ec7 8. /build/src/Functions/FunctionBinaryArithmetic.h:844: DB::FunctionBinaryArithmetic::executeImpl2(std::vector> const&, std::shared_ptr const&, unsigned long, DB::PODArray, 63ul, 64ul> const*) const @ 0x000000000d3a03c5 9. /build/src/Functions/FunctionBinaryArithmetic.h:2410: DB::FunctionBinaryArithmetic::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000d39e94c 10. /build/src/Functions/FunctionBinaryArithmetic.h:2645: DB::FunctionBinaryArithmeticWithConstants::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000d39dbd4 11. /build/src/Functions/IFunctionAdaptors.cpp:10: DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000012d995fa 12. /build/src/Functions/IFunction.cpp:353: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d93b52 13. /build/src/Functions/IFunction.cpp:420: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d95059 14. /build/src/Functions/IFunction.cpp:498: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d95c72 15. /build/src/Interpreters/ExpressionActions.cpp:636: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x00000000145176f3 16. /build/src/Processors/Transforms/ExpressionTransform.cpp:25: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x0000000016c0b34c 17. /build/src/Processors/ISimpleTransform.h:33: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000011a9a453 18. /build/src/Processors/ISimpleTransform.cpp:89: DB::ISimpleTransform::work() @ 0x000000001699fca0 19. /build/src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x00000000169bd00f 20. /build/src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x00000000169b2105 21. /build/src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeSingleThread(unsigned long) @ 0x00000000169b23be 22. /build/src/Processors/Executors/PipelineExecutor.cpp:454: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x00000000169b0be7 23. /build/src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x00000000169b03f4 24. /build/src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:se190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169bfeab 25. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc3d92 26. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fcca080 27. ? @ 0x00007fbc6213eac3 28. ? @ 0x00007fbc621d0850 2025.07.28 11:54:21.939623 [ 17251 ] {} TCPHandler: Code: 153. DB::Exception: Division by zero: while executing 'FUNCTION modulo(1_UInt8 :: 1, modulo(plus(__table1.number, 500_UInt16), 1000_UInt16) :: 2) -> modulo(1_UInt8, modulo(plus(__table1.number, 500_UInt16), 1000_UInt16)) UInt16 : 3'. (ILLEGAL_DIVISION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000000a074fcb 4. /build/src/Functions/DivisionUtils.h:26: void DB::impl_::BinaryOperation, unsigned short>::process<(DB::impl_::OpCase)1>(char8_t const*, unsigned short const*, unsigned short*, unsigned long, DB::PODArray, 63ul, 64ul> const*) @ 0x000000000d184621 5. /build/src/Functions/FunctionBinaryArithmetic.h:2338: COW::immutable_ptr DB::FunctionBinaryArithmetic::executeNumeric, DB::DataTypeNumber>(std::vector> const&, DB::DataTypeNumber const&, DB::DataTypeNumber const&, DB::PODArray, 63ul, 64ul> const*) const @ 0x000000000d3a6416 6. /build/src/Functions/FunctionBinaryArithmetic.h:2508: 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&&) @ 0x000000000d3a4a68 7. /build/src/Functions/FunctionBinaryArithmetic.h:846: 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&&) @ 0x000000000d3a3ec7 8. /build/src/Functions/FunctionBinaryArithmetic.h:844: DB::FunctionBinaryArithmetic::executeImpl2(std::vector> const&, std::shared_ptr const&, unsigned long, DB::PODArray, 63ul, 64ul> const*) const @ 0x000000000d3a03c5 9. /build/src/Functions/FunctionBinaryArithmetic.h:2410: DB::FunctionBinaryArithmetic::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000d39e94c 10. /build/src/Functions/FunctionBinaryArithmetic.h:2645: DB::FunctionBinaryArithmeticWithConstants::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000d39dbd4 11. /build/src/Functions/IFunctionAdaptors.cpp:10: DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000012d995fa 12. /build/src/Functions/IFunction.cpp:353: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d93b52 13. /build/src/Functions/IFunction.cpp:420: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d95059 14. /build/src/Functions/IFunction.cpp:498: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d95c72 15. /build/src/Interpreters/ExpressionActions.cpp:636: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x00000000145176f3 16. /build/src/Processors/Transforms/ExpressionTransform.cpp:25: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x0000000016c0b34c 17. /build/src/Processors/ISimpleTransform.h:33: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000011a9a453 18. /build/src/Processors/ISimpleTransform.cpp:89: DB::ISimpleTransform::work() @ 0x000000001699fca0 19. /build/src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x00000000169bd00f 20. /build/src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x00000000169b2105 21. /build/src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeSingleThread(unsigned long) @ 0x00000000169b23be 22. /build/src/Processors/Executors/PipelineExecutor.cpp:454: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x00000000169b0be7 23. /build/src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x00000000169b03f4 24. /build/src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:se190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169bfeab 25. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc3d92 26. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fcca080 27. ? @ 0x00007fbc6213eac3 28. ? @ 0x00007fbc621d0850 Job's origin stack trace: 0. /build/src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000000fc33b84 1. /build/src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000000fcc2ea7 2. /build/src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fcc535c 3. /build/src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000000fcc584d 4. /build/src/Common/ThreadPool.h:279: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x00000000169bf193 5. /build/src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x00000000169bf518 6. /build/src/Server/TCPHandler.cpp:1237: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x00000000168f1525 7. /build/src/Server/TCPHandler.cpp:678: DB::TCPHandler::runImpl() @ 0x00000000168e68e5 8. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 9. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 10. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 11. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 12. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 13. ? @ 0x00007fbc6213eac3 14. ? @ 0x00007fbc621d0850 2025.07.28 11:54:22.590608 [ 3960 ] {} test_13.rmt2 (7f9b740d-015c-470e-8cc6-8ba33be0dc63): auto DB::StorageReplicatedMergeTree::processQueueEntry(ReplicatedMergeTreeQueue::SelectedEntryPtr)::(anonymous class)::operator()(LogEntryPtr &) const: Code: 86. DB::HTTPException: Received error from remote server http://146b4357c08d:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Ftest%2F01165%2Ftest_13%2Frmt%2Freplicas%2F1&part=20250728_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.6.10636.altinitytest (altinity build)) '. (RECEIVED_ERROR_FROM_REMOTE_IO_SERVER), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.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 const&, int&&, String const&, unsigned long&&, String const&) @ 0x000000000feda8d9 4. /build/src/IO/HTTPCommon.cpp:104: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x000000000feda6e2 5. /build/src/IO/HTTPCommon.cpp:93: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x000000000feda537 6. /build/src/IO/ReadWriteBufferFromHTTP.cpp:277: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x000000001184a4c4 7. /build/src/IO/ReadWriteBufferFromHTTP.cpp:285: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x000000001184a615 8. /build/src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x000000001184ae59 9. /build/src/IO/ReadWriteBufferFromHTTP.cpp:472: void std::__function::__policy_invoker::__call_impl[abi:se190107]>(std::__function::__policy_storage const*) @ 0x000000001184cedd 10. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001184858b 11. /build/src/IO/ReadWriteBufferFromHTTP.cpp:465: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x000000001184bf0b 12. /build/src/IO/ReadBuffer.h:60: DB::ReadBuffer::next() @ 0x000000000a148c7b 13. /build/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) @ 0x0000000011849fb2 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]>&)>&, 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&) @ 0x0000000011841980 15. /build/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) @ 0x000000001621208e 16. /build/src/Storages/StorageReplicatedMergeTree.cpp:5228: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl[abi:se190107] const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000015f9a5fe 17. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000015ed8bfd 18. /build/src/Storages/StorageReplicatedMergeTree.cpp:2514: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x0000000015ec9aab 19. /build/src/Storages/StorageReplicatedMergeTree.cpp:2349: DB::StorageReplicatedMergeTree::executeLogEntry(DB::ReplicatedMergeTreeLogEntry&) @ 0x0000000015eba91b 20. /build/src/Storages/StorageReplicatedMergeTree.cpp:3876: bool std::__function::__policy_invoker&)>::__call_impl[abi:se190107])::$_1, bool (std::shared_ptr&)>>(std::__function::__policy_storage const*, std::shared_ptr&) @ 0x0000000015f9837e 21. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000165d6fc3 22. /build/src/Storages/StorageReplicatedMergeTree.cpp:3872: DB::StorageReplicatedMergeTree::processQueueEntry(std::shared_ptr) @ 0x0000000015efc18a 23. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001624c1b2 24. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000162f9c70 25. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x00000000162fa55a 26. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc6653 27. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000000fccc4c3 28. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc3d92 29. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fcca080 30. ? @ 0x00007fbc6213eac3 31. ? @ 0x00007fbc621d0850 (version 25.3.6.10636.altinitytest (altinity build)) 2025.07.28 11:54:22.742506 [ 3967 ] {} test_13.rmt2 (7f9b740d-015c-470e-8cc6-8ba33be0dc63): auto DB::StorageReplicatedMergeTree::processQueueEntry(ReplicatedMergeTreeQueue::SelectedEntryPtr)::(anonymous class)::operator()(LogEntryPtr &) const: Code: 86. DB::HTTPException: Received error from remote server http://146b4357c08d:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Ftest%2F01165%2Ftest_13%2Frmt%2Freplicas%2F1&part=20250728_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.6.10636.altinitytest (altinity build)) '. (RECEIVED_ERROR_FROM_REMOTE_IO_SERVER), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.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 const&, int&&, String const&, unsigned long&&, String const&) @ 0x000000000feda8d9 4. /build/src/IO/HTTPCommon.cpp:104: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x000000000feda6e2 5. /build/src/IO/HTTPCommon.cpp:93: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x000000000feda537 6. /build/src/IO/ReadWriteBufferFromHTTP.cpp:277: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x000000001184a4c4 7. /build/src/IO/ReadWriteBufferFromHTTP.cpp:285: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x000000001184a615 8. /build/src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x000000001184ae59 9. /build/src/IO/ReadWriteBufferFromHTTP.cpp:472: void std::__function::__policy_invoker::__call_impl[abi:se190107]>(std::__function::__policy_storage const*) @ 0x000000001184cedd 10. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001184858b 11. /build/src/IO/ReadWriteBufferFromHTTP.cpp:465: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x000000001184bf0b 12. /build/src/IO/ReadBuffer.h:60: DB::ReadBuffer::next() @ 0x000000000a148c7b 13. /build/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) @ 0x0000000011849fb2 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]>&)>&, 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&) @ 0x0000000011841980 15. /build/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) @ 0x000000001621208e 16. /build/src/Storages/StorageReplicatedMergeTree.cpp:5228: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl[abi:se190107] const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000015f9a5fe 17. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000015ed8bfd 18. /build/src/Storages/StorageReplicatedMergeTree.cpp:2514: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x0000000015ec9aab 19. /build/src/Storages/StorageReplicatedMergeTree.cpp:2349: DB::StorageReplicatedMergeTree::executeLogEntry(DB::ReplicatedMergeTreeLogEntry&) @ 0x0000000015eba91b 20. /build/src/Storages/StorageReplicatedMergeTree.cpp:3876: bool std::__function::__policy_invoker&)>::__call_impl[abi:se190107])::$_1, bool (std::shared_ptr&)>>(std::__function::__policy_storage const*, std::shared_ptr&) @ 0x0000000015f9837e 21. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000165d6fc3 22. /build/src/Storages/StorageReplicatedMergeTree.cpp:3872: DB::StorageReplicatedMergeTree::processQueueEntry(std::shared_ptr) @ 0x0000000015efc18a 23. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001624c1b2 24. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000162f9c70 25. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x00000000162fa55a 26. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc6653 27. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000000fccc4c3 28. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc3d92 29. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fcca080 30. ? @ 0x00007fbc6213eac3 31. ? @ 0x00007fbc621d0850 (version 25.3.6.10636.altinitytest (altinity build)) 2025.07.28 11:54:23.487219 [ 3970 ] {} test_13.rmt2 (7f9b740d-015c-470e-8cc6-8ba33be0dc63): auto DB::StorageReplicatedMergeTree::processQueueEntry(ReplicatedMergeTreeQueue::SelectedEntryPtr)::(anonymous class)::operator()(LogEntryPtr &) const: Code: 86. DB::HTTPException: Received error from remote server http://146b4357c08d:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Ftest%2F01165%2Ftest_13%2Frmt%2Freplicas%2F1&part=20250728_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.6.10636.altinitytest (altinity build)) '. (RECEIVED_ERROR_FROM_REMOTE_IO_SERVER), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.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 const&, int&&, String const&, unsigned long&&, String const&) @ 0x000000000feda8d9 4. /build/src/IO/HTTPCommon.cpp:104: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x000000000feda6e2 5. /build/src/IO/HTTPCommon.cpp:93: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x000000000feda537 6. /build/src/IO/ReadWriteBufferFromHTTP.cpp:277: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x000000001184a4c4 7. /build/src/IO/ReadWriteBufferFromHTTP.cpp:285: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x000000001184a615 8. /build/src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x000000001184ae59 9. /build/src/IO/ReadWriteBufferFromHTTP.cpp:472: void std::__function::__policy_invoker::__call_impl[abi:se190107]>(std::__function::__policy_storage const*) @ 0x000000001184cedd 10. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001184858b 11. /build/src/IO/ReadWriteBufferFromHTTP.cpp:465: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x000000001184bf0b 12. /build/src/IO/ReadBuffer.h:60: DB::ReadBuffer::next() @ 0x000000000a148c7b 13. /build/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) @ 0x0000000011849fb2 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]>&)>&, 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&) @ 0x0000000011841980 15. /build/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) @ 0x000000001621208e 16. /build/src/Storages/StorageReplicatedMergeTree.cpp:5228: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl[abi:se190107] const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000015f9a5fe 17. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000015ed8bfd 18. /build/src/Storages/StorageReplicatedMergeTree.cpp:2514: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x0000000015ec9aab 19. /build/src/Storages/StorageReplicatedMergeTree.cpp:2349: DB::StorageReplicatedMergeTree::executeLogEntry(DB::ReplicatedMergeTreeLogEntry&) @ 0x0000000015eba91b 20. /build/src/Storages/StorageReplicatedMergeTree.cpp:3876: bool std::__function::__policy_invoker&)>::__call_impl[abi:se190107])::$_1, bool (std::shared_ptr&)>>(std::__function::__policy_storage const*, std::shared_ptr&) @ 0x0000000015f9837e 21. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000165d6fc3 22. /build/src/Storages/StorageReplicatedMergeTree.cpp:3872: DB::StorageReplicatedMergeTree::processQueueEntry(std::shared_ptr) @ 0x0000000015efc18a 23. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001624c1b2 24. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000162f9c70 25. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x00000000162fa55a 26. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc6653 27. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000000fccc4c3 28. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc3d92 29. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fcca080 30. ? @ 0x00007fbc6213eac3 31. ? @ 0x00007fbc621d0850 (version 25.3.6.10636.altinitytest (altinity build)) 2025.07.28 11:54:23.610252 [ 17255 ] {2c72df59-47ca-4a67-8f7d-5e445a496778} executeQuery: Code: 378. DB::Exception: Data type Bool cannot have arguments: In scope SELECT CAST('0', 'Bool(Upyachka)'). (DATA_TYPE_CANNOT_HAVE_ARGUMENTS) (version 25.3.6.10636.altinitytest (altinity build)) (from [::1]:47966) (comment: 02689_meaningless_data_types.sql) (query 1, line 1) (in query: SELECT 0::Bool(Upyachka);), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000a9b78ab 4. /build/src/DataTypes/DataTypeFactory.cpp:213: std::pair, std::unique_ptr>> std::__function::__policy_invoker, std::unique_ptr>> (std::shared_ptr const&)>::__call_impl[abi:se190107], std::unique_ptr>> ()>, DB::IFactoryWithAliases (std::shared_ptr const&)>>::Case)::$_0, std::pair, std::unique_ptr>> (std::shared_ptr const&)>>(std::__function::__policy_storage const*, std::shared_ptr const&) @ 0x0000000013be8a1c 5. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000013be87f7 6. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000013be94fb 7. /build/src/DataTypes/DataTypeFactory.cpp:91: std::shared_ptr DB::DataTypeFactory::getImpl(std::shared_ptr const&) const @ 0x0000000013be8f9e 8. /build/src/DataTypes/DataTypeFactory.cpp:73: std::shared_ptr DB::DataTypeFactory::getImpl(String const&) const @ 0x0000000013be8c72 9. /build/src/Functions/CastOverloadResolver.cpp:127: DB::CastOverloadResolverImpl::getReturnTypeImpl(std::vector> const&) const @ 0x0000000012dcd46d 10. /build/src/Functions/IFunction.cpp:645: DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x0000000012d96b0c 11. /build/src/Functions/IFunction.cpp:585: DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x0000000012d9665b 12. /build/src/Functions/IFunction.cpp:606: DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x0000000012d96edc 13. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3544: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000014033cc9 14. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3838: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000014019a9e 15. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3980: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000014018e31 16. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:4304: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000014042fa7 17. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5605: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000014013749 18. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000140127f9 19. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000014011fce 20. /build/src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000001406ce8a 21. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000014973b42 22. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000001497268d 23. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000014974d24 24. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001492924b 25. /build/src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88641 26. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 27. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 28. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 29. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 30. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 31. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 2025.07.28 11:54:23.614695 [ 17255 ] {} TCPHandler: Code: 378. DB::Exception: Data type Bool cannot have arguments: In scope SELECT CAST('0', 'Bool(Upyachka)'). (DATA_TYPE_CANNOT_HAVE_ARGUMENTS), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000a9b78ab 4. /build/src/DataTypes/DataTypeFactory.cpp:213: std::pair, std::unique_ptr>> std::__function::__policy_invoker, std::unique_ptr>> (std::shared_ptr const&)>::__call_impl[abi:se190107], std::unique_ptr>> ()>, DB::IFactoryWithAliases (std::shared_ptr const&)>>::Case)::$_0, std::pair, std::unique_ptr>> (std::shared_ptr const&)>>(std::__function::__policy_storage const*, std::shared_ptr const&) @ 0x0000000013be8a1c 5. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000013be87f7 6. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000013be94fb 7. /build/src/DataTypes/DataTypeFactory.cpp:91: std::shared_ptr DB::DataTypeFactory::getImpl(std::shared_ptr const&) const @ 0x0000000013be8f9e 8. /build/src/DataTypes/DataTypeFactory.cpp:73: std::shared_ptr DB::DataTypeFactory::getImpl(String const&) const @ 0x0000000013be8c72 9. /build/src/Functions/CastOverloadResolver.cpp:127: DB::CastOverloadResolverImpl::getReturnTypeImpl(std::vector> const&) const @ 0x0000000012dcd46d 10. /build/src/Functions/IFunction.cpp:645: DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x0000000012d96b0c 11. /build/src/Functions/IFunction.cpp:585: DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x0000000012d9665b 12. /build/src/Functions/IFunction.cpp:606: DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x0000000012d96edc 13. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3544: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000014033cc9 14. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3838: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000014019a9e 15. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3980: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000014018e31 16. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:4304: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000014042fa7 17. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5605: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000014013749 18. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000140127f9 19. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000014011fce 20. /build/src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000001406ce8a 21. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000014973b42 22. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000001497268d 23. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000014974d24 24. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001492924b 25. /build/src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88641 26. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 27. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 28. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 29. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 30. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 31. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 2025.07.28 11:54:23.653456 [ 17255 ] {682d22d6-79e4-4d8e-ae11-ad6b0a1a3a6c} executeQuery: Code: 378. DB::Exception: Data type Ring cannot have arguments: In scope SELECT CAST('[(1, 2), (3, 4)]', 'Ring(Upyachka)'). (DATA_TYPE_CANNOT_HAVE_ARGUMENTS) (version 25.3.6.10636.altinitytest (altinity build)) (from [::1]:47966) (comment: 02689_meaningless_data_types.sql) (query 2, line 2) (in query: SELECT [(1, 2), (3, 4)]::Ring(Upyachka);), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000a9b78ab 4. /build/src/DataTypes/DataTypeFactory.cpp:213: std::pair, std::unique_ptr>> std::__function::__policy_invoker, std::unique_ptr>> (std::shared_ptr const&)>::__call_impl[abi:se190107], std::unique_ptr>> ()>, DB::IFactoryWithAliases (std::shared_ptr const&)>>::Case)::$_0, std::pair, std::unique_ptr>> (std::shared_ptr const&)>>(std::__function::__policy_storage const*, std::shared_ptr const&) @ 0x0000000013be8a1c 5. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000013be87f7 6. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000013be94fb 7. /build/src/DataTypes/DataTypeFactory.cpp:91: std::shared_ptr DB::DataTypeFactory::getImpl(std::shared_ptr const&) const @ 0x0000000013be8f9e 8. /build/src/DataTypes/DataTypeFactory.cpp:73: std::shared_ptr DB::DataTypeFactory::getImpl(String const&) const @ 0x0000000013be8c72 9. /build/src/Functions/CastOverloadResolver.cpp:127: DB::CastOverloadResolverImpl::getReturnTypeImpl(std::vector> const&) const @ 0x0000000012dcd46d 10. /build/src/Functions/IFunction.cpp:645: DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x0000000012d96b0c 11. /build/src/Functions/IFunction.cpp:585: DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x0000000012d9665b 12. /build/src/Functions/IFunction.cpp:606: DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x0000000012d96edc 13. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3544: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000014033cc9 14. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3838: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000014019a9e 15. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3980: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000014018e31 16. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:4304: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000014042fa7 17. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5605: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000014013749 18. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000140127f9 19. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000014011fce 20. /build/src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000001406ce8a 21. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000014973b42 22. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000001497268d 23. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000014974d24 24. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001492924b 25. /build/src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88641 26. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 27. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 28. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 29. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 30. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 31. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 2025.07.28 11:54:23.658072 [ 17255 ] {} TCPHandler: Code: 378. DB::Exception: Data type Ring cannot have arguments: In scope SELECT CAST('[(1, 2), (3, 4)]', 'Ring(Upyachka)'). (DATA_TYPE_CANNOT_HAVE_ARGUMENTS), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000a9b78ab 4. /build/src/DataTypes/DataTypeFactory.cpp:213: std::pair, std::unique_ptr>> std::__function::__policy_invoker, std::unique_ptr>> (std::shared_ptr const&)>::__call_impl[abi:se190107], std::unique_ptr>> ()>, DB::IFactoryWithAliases (std::shared_ptr const&)>>::Case)::$_0, std::pair, std::unique_ptr>> (std::shared_ptr const&)>>(std::__function::__policy_storage const*, std::shared_ptr const&) @ 0x0000000013be8a1c 5. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000013be87f7 6. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000013be94fb 7. /build/src/DataTypes/DataTypeFactory.cpp:91: std::shared_ptr DB::DataTypeFactory::getImpl(std::shared_ptr const&) const @ 0x0000000013be8f9e 8. /build/src/DataTypes/DataTypeFactory.cpp:73: std::shared_ptr DB::DataTypeFactory::getImpl(String const&) const @ 0x0000000013be8c72 9. /build/src/Functions/CastOverloadResolver.cpp:127: DB::CastOverloadResolverImpl::getReturnTypeImpl(std::vector> const&) const @ 0x0000000012dcd46d 10. /build/src/Functions/IFunction.cpp:645: DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x0000000012d96b0c 11. /build/src/Functions/IFunction.cpp:585: DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x0000000012d9665b 12. /build/src/Functions/IFunction.cpp:606: DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x0000000012d96edc 13. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3544: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000014033cc9 14. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3838: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000014019a9e 15. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3980: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000014018e31 16. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:4304: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000014042fa7 17. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5605: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000014013749 18. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000140127f9 19. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000014011fce 20. /build/src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000001406ce8a 21. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000014973b42 22. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000001497268d 23. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000014974d24 24. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001492924b 25. /build/src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88641 26. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 27. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 28. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 29. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 30. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 31. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 2025.07.28 11:54:23.750280 [ 3965 ] {} test_13.rmt2 (7f9b740d-015c-470e-8cc6-8ba33be0dc63): auto DB::StorageReplicatedMergeTree::processQueueEntry(ReplicatedMergeTreeQueue::SelectedEntryPtr)::(anonymous class)::operator()(LogEntryPtr &) const: Code: 86. DB::HTTPException: Received error from remote server http://146b4357c08d:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Ftest%2F01165%2Ftest_13%2Frmt%2Freplicas%2F1&part=20250728_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.6.10636.altinitytest (altinity build)) '. (RECEIVED_ERROR_FROM_REMOTE_IO_SERVER), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.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 const&, int&&, String const&, unsigned long&&, String const&) @ 0x000000000feda8d9 4. /build/src/IO/HTTPCommon.cpp:104: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x000000000feda6e2 5. /build/src/IO/HTTPCommon.cpp:93: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x000000000feda537 6. /build/src/IO/ReadWriteBufferFromHTTP.cpp:277: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x000000001184a4c4 7. /build/src/IO/ReadWriteBufferFromHTTP.cpp:285: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x000000001184a615 8. /build/src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x000000001184ae59 9. /build/src/IO/ReadWriteBufferFromHTTP.cpp:472: void std::__function::__policy_invoker::__call_impl[abi:se190107]>(std::__function::__policy_storage const*) @ 0x000000001184cedd 10. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001184858b 11. /build/src/IO/ReadWriteBufferFromHTTP.cpp:465: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x000000001184bf0b 12. /build/src/IO/ReadBuffer.h:60: DB::ReadBuffer::next() @ 0x000000000a148c7b 13. /build/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) @ 0x0000000011849fb2 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]>&)>&, 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&) @ 0x0000000011841980 15. /build/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) @ 0x000000001621208e 16. /build/src/Storages/StorageReplicatedMergeTree.cpp:5228: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl[abi:se190107] const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000015f9a5fe 17. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000015ed8bfd 18. /build/src/Storages/StorageReplicatedMergeTree.cpp:2514: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x0000000015ec9aab 19. /build/src/Storages/StorageReplicatedMergeTree.cpp:2349: DB::StorageReplicatedMergeTree::executeLogEntry(DB::ReplicatedMergeTreeLogEntry&) @ 0x0000000015eba91b 20. /build/src/Storages/StorageReplicatedMergeTree.cpp:3876: bool std::__function::__policy_invoker&)>::__call_impl[abi:se190107])::$_1, bool (std::shared_ptr&)>>(std::__function::__policy_storage const*, std::shared_ptr&) @ 0x0000000015f9837e 21. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000165d6fc3 22. /build/src/Storages/StorageReplicatedMergeTree.cpp:3872: DB::StorageReplicatedMergeTree::processQueueEntry(std::shared_ptr) @ 0x0000000015efc18a 23. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001624c1b2 24. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000162f9c70 25. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x00000000162fa55a 26. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc6653 27. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000000fccc4c3 28. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc3d92 29. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fcca080 30. ? @ 0x00007fbc6213eac3 31. ? @ 0x00007fbc621d0850 (version 25.3.6.10636.altinitytest (altinity build)) 2025.07.28 11:54:23.791881 [ 17255 ] {ea994486-7863-4185-ba9c-ca5fee2243c6} executeQuery: Code: 378. DB::Exception: Data type IPv4 cannot have arguments: In scope SELECT CAST('1.1.1.1', 'IPv4(\'Hello, world!\')'). (DATA_TYPE_CANNOT_HAVE_ARGUMENTS) (version 25.3.6.10636.altinitytest (altinity build)) (from [::1]:47966) (comment: 02689_meaningless_data_types.sql) (query 3, line 3) (in query: SELECT '1.1.1.1'::IPv4('Hello, world!');), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000a9b78ab 4. /build/src/DataTypes/DataTypeFactory.cpp:192: std::shared_ptr std::__function::__policy_invoker (std::shared_ptr const&)>::__call_impl[abi:se190107] ()>, DB::IFactoryWithAliases (std::shared_ptr const&)>>::Case)::$_0, std::shared_ptr (std::shared_ptr const&)>>(std::__function::__policy_storage const*, std::shared_ptr const&) @ 0x0000000013be8658 5. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000013be94fb 6. /build/src/DataTypes/DataTypeFactory.cpp:91: std::shared_ptr DB::DataTypeFactory::getImpl(std::shared_ptr const&) const @ 0x0000000013be8f9e 7. /build/src/DataTypes/DataTypeFactory.cpp:73: std::shared_ptr DB::DataTypeFactory::getImpl(String const&) const @ 0x0000000013be8c72 8. /build/src/Functions/CastOverloadResolver.cpp:127: DB::CastOverloadResolverImpl::getReturnTypeImpl(std::vector> const&) const @ 0x0000000012dcd46d 9. /build/src/Functions/IFunction.cpp:645: DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x0000000012d96b0c 10. /build/src/Functions/IFunction.cpp:585: DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x0000000012d9665b 11. /build/src/Functions/IFunction.cpp:606: DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x0000000012d96edc 12. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3544: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000014033cc9 13. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3838: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000014019a9e 14. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3980: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000014018e31 15. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:4304: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000014042fa7 16. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5605: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000014013749 17. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000140127f9 18. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000014011fce 19. /build/src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000001406ce8a 20. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000014973b42 21. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000001497268d 22. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000014974d24 23. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001492924b 24. /build/src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88641 25. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 26. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 27. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 28. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 29. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 30. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 31. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 2025.07.28 11:54:23.796075 [ 17255 ] {} TCPHandler: Code: 378. DB::Exception: Data type IPv4 cannot have arguments: In scope SELECT CAST('1.1.1.1', 'IPv4(\'Hello, world!\')'). (DATA_TYPE_CANNOT_HAVE_ARGUMENTS), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000a9b78ab 4. /build/src/DataTypes/DataTypeFactory.cpp:192: std::shared_ptr std::__function::__policy_invoker (std::shared_ptr const&)>::__call_impl[abi:se190107] ()>, DB::IFactoryWithAliases (std::shared_ptr const&)>>::Case)::$_0, std::shared_ptr (std::shared_ptr const&)>>(std::__function::__policy_storage const*, std::shared_ptr const&) @ 0x0000000013be8658 5. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000013be94fb 6. /build/src/DataTypes/DataTypeFactory.cpp:91: std::shared_ptr DB::DataTypeFactory::getImpl(std::shared_ptr const&) const @ 0x0000000013be8f9e 7. /build/src/DataTypes/DataTypeFactory.cpp:73: std::shared_ptr DB::DataTypeFactory::getImpl(String const&) const @ 0x0000000013be8c72 8. /build/src/Functions/CastOverloadResolver.cpp:127: DB::CastOverloadResolverImpl::getReturnTypeImpl(std::vector> const&) const @ 0x0000000012dcd46d 9. /build/src/Functions/IFunction.cpp:645: DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x0000000012d96b0c 10. /build/src/Functions/IFunction.cpp:585: DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x0000000012d9665b 11. /build/src/Functions/IFunction.cpp:606: DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x0000000012d96edc 12. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3544: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000014033cc9 13. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3838: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000014019a9e 14. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3980: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000014018e31 15. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:4304: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000014042fa7 16. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5605: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000014013749 17. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000140127f9 18. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000014011fce 19. /build/src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000001406ce8a 20. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000014973b42 21. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000001497268d 22. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000014974d24 23. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001492924b 24. /build/src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88641 25. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 26. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 27. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 28. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 29. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 30. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 31. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 2025.07.28 11:54:24.219723 [ 3963 ] {} test_13.rmt2 (7f9b740d-015c-470e-8cc6-8ba33be0dc63): auto DB::StorageReplicatedMergeTree::processQueueEntry(ReplicatedMergeTreeQueue::SelectedEntryPtr)::(anonymous class)::operator()(LogEntryPtr &) const: Code: 86. DB::HTTPException: Received error from remote server http://146b4357c08d:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Ftest%2F01165%2Ftest_13%2Frmt%2Freplicas%2F1&part=20250728_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.6.10636.altinitytest (altinity build)) '. (RECEIVED_ERROR_FROM_REMOTE_IO_SERVER), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.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 const&, int&&, String const&, unsigned long&&, String const&) @ 0x000000000feda8d9 4. /build/src/IO/HTTPCommon.cpp:104: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x000000000feda6e2 5. /build/src/IO/HTTPCommon.cpp:93: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x000000000feda537 6. /build/src/IO/ReadWriteBufferFromHTTP.cpp:277: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x000000001184a4c4 7. /build/src/IO/ReadWriteBufferFromHTTP.cpp:285: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x000000001184a615 8. /build/src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x000000001184ae59 9. /build/src/IO/ReadWriteBufferFromHTTP.cpp:472: void std::__function::__policy_invoker::__call_impl[abi:se190107]>(std::__function::__policy_storage const*) @ 0x000000001184cedd 10. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001184858b 11. /build/src/IO/ReadWriteBufferFromHTTP.cpp:465: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x000000001184bf0b 12. /build/src/IO/ReadBuffer.h:60: DB::ReadBuffer::next() @ 0x000000000a148c7b 13. /build/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) @ 0x0000000011849fb2 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]>&)>&, 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&) @ 0x0000000011841980 15. /build/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) @ 0x000000001621208e 16. /build/src/Storages/StorageReplicatedMergeTree.cpp:5228: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl[abi:se190107] const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000015f9a5fe 17. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000015ed8bfd 18. /build/src/Storages/StorageReplicatedMergeTree.cpp:2514: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x0000000015ec9aab 19. /build/src/Storages/StorageReplicatedMergeTree.cpp:2349: DB::StorageReplicatedMergeTree::executeLogEntry(DB::ReplicatedMergeTreeLogEntry&) @ 0x0000000015eba91b 20. /build/src/Storages/StorageReplicatedMergeTree.cpp:3876: bool std::__function::__policy_invoker&)>::__call_impl[abi:se190107])::$_1, bool (std::shared_ptr&)>>(std::__function::__policy_storage const*, std::shared_ptr&) @ 0x0000000015f9837e 21. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000165d6fc3 22. /build/src/Storages/StorageReplicatedMergeTree.cpp:3872: DB::StorageReplicatedMergeTree::processQueueEntry(std::shared_ptr) @ 0x0000000015efc18a 23. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001624c1b2 24. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000162f9c70 25. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x00000000162fa55a 26. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc6653 27. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000000fccc4c3 28. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc3d92 29. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fcca080 30. ? @ 0x00007fbc6213eac3 31. ? @ 0x00007fbc621d0850 (version 25.3.6.10636.altinitytest (altinity build)) 2025.07.28 11:54:24.590762 [ 17191 ] {1c9d7cc2-c710-4f9c-987b-864b255a8c17} executeQuery: Code: 475. DB::Exception: The same column in ORDER BY before WITH FILL (sorting prefix) and INTERPOLATE is not allowed. Column: __table1.value. (INVALID_WITH_FILL_EXPRESSION) (version 25.3.6.10636.altinitytest (altinity build)) (from [::1]:45986) (comment: 02730_with_fill_by_sorting_prefix.sql) (query 32, line 59) (in query: -- checking that sorting prefix columns can't be used in INTERPOLATE SELECT * FROM ts ORDER BY sensor_id, value, timestamp WITH FILL FROM 6 TO 10 INTERPOLATE ( value AS 1 );), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000a9b78ab 4. /build/src/Processors/Transforms/FillingTransform.cpp:333: DB::FillingTransform::FillingTransform(DB::Block const&, DB::SortDescription const&, DB::SortDescription const&, std::shared_ptr, bool) @ 0x0000000016dbf62d 5. /build/contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: std::shared_ptr std::__function::__policy_invoker (DB::Block const&, DB::Pipe::StreamType)>::__call_impl[abi:se190107] (DB::Block const&, DB::Pipe::StreamType)>>(std::__function::__policy_storage const*, DB::Block const&, DB::Pipe::StreamType) @ 0x0000000016dbb21f 6. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000013b9418e 7. /build/src/QueryPipeline/Pipe.cpp:632: DB::Pipe::addSimpleTransform(std::function (DB::Block const&, DB::Pipe::StreamType)> const&) @ 0x0000000013b93f5d 8. /build/src/Processors/QueryPlan/FillingStep.cpp:50: DB::FillingStep::transformPipeline(DB::QueryPipelineBuilder&, DB::BuildQueryPipelineSettings const&) @ 0x0000000016dba7c8 9. /build/src/Processors/QueryPlan/ITransformingStep.cpp:21: DB::ITransformingStep::updatePipeline(std::vector>, std::allocator>>>, DB::BuildQueryPipelineSettings const&) @ 0x0000000016dd1ba5 10. /build/src/Processors/QueryPlan/QueryPlan.cpp:201: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x0000000016e0076f 11. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:275: DB::InterpreterSelectQueryAnalyzer::buildQueryPipeline() @ 0x0000000014974614 12. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:242: DB::InterpreterSelectQueryAnalyzer::execute() @ 0x000000001497439e 13. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88dc9 14. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 15. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 16. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 17. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 18. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 19. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 20. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 21. ? @ 0x00007fbc6213eac3 22. ? @ 0x00007fbc621d0850 2025.07.28 11:54:24.605184 [ 17191 ] {} TCPHandler: Code: 475. DB::Exception: The same column in ORDER BY before WITH FILL (sorting prefix) and INTERPOLATE is not allowed. Column: __table1.value. (INVALID_WITH_FILL_EXPRESSION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000a9b78ab 4. /build/src/Processors/Transforms/FillingTransform.cpp:333: DB::FillingTransform::FillingTransform(DB::Block const&, DB::SortDescription const&, DB::SortDescription const&, std::shared_ptr, bool) @ 0x0000000016dbf62d 5. /build/contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: std::shared_ptr std::__function::__policy_invoker (DB::Block const&, DB::Pipe::StreamType)>::__call_impl[abi:se190107] (DB::Block const&, DB::Pipe::StreamType)>>(std::__function::__policy_storage const*, DB::Block const&, DB::Pipe::StreamType) @ 0x0000000016dbb21f 6. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000013b9418e 7. /build/src/QueryPipeline/Pipe.cpp:632: DB::Pipe::addSimpleTransform(std::function (DB::Block const&, DB::Pipe::StreamType)> const&) @ 0x0000000013b93f5d 8. /build/src/Processors/QueryPlan/FillingStep.cpp:50: DB::FillingStep::transformPipeline(DB::QueryPipelineBuilder&, DB::BuildQueryPipelineSettings const&) @ 0x0000000016dba7c8 9. /build/src/Processors/QueryPlan/ITransformingStep.cpp:21: DB::ITransformingStep::updatePipeline(std::vector>, std::allocator>>>, DB::BuildQueryPipelineSettings const&) @ 0x0000000016dd1ba5 10. /build/src/Processors/QueryPlan/QueryPlan.cpp:201: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x0000000016e0076f 11. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:275: DB::InterpreterSelectQueryAnalyzer::buildQueryPipeline() @ 0x0000000014974614 12. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:242: DB::InterpreterSelectQueryAnalyzer::execute() @ 0x000000001497439e 13. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88dc9 14. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 15. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 16. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 17. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 18. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 19. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 20. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 21. ? @ 0x00007fbc6213eac3 22. ? @ 0x00007fbc621d0850 2025.07.28 11:54:24.827399 [ 17255 ] {29bab4e9-2022-4ef9-8fb4-3820e3f6078d} executeQuery: Code: 42. DB::Exception: Table function 'executable' requires minimum 3 arguments: script_name, format, structure, [input_query...]. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.6.10636.altinitytest (altinity build)) (from [::1]:47986) (comment: 03006_analyzer_executable_table_function.sql) (query 1, line 1) (in query: SELECT toFixedString(toFixedString(toLowCardinality(toFixedString('--------------------', toNullable(20))), toLowCardinality(20)), 20), * FROM executable('data String', SETTINGS max_command_execution_time = 100);), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x000000000a06b56b 4. /build/src/TableFunctions/TableFunctionExecutable.cpp:98: DB::(anonymous namespace)::TableFunctionExecutable::parseArguments(std::shared_ptr const&, std::shared_ptr) @ 0x0000000011821d80 5. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:4834: DB::QueryAnalyzer::resolveTableFunction(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&, bool) @ 0x000000001401cb85 6. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5342: DB::QueryAnalyzer::resolveQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&) @ 0x00000000140452bf 7. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5597: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000140136f0 8. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000140127f9 9. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000014011fce 10. /build/src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000001406ce8a 11. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000014973b42 12. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000001497268d 13. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000014974d24 14. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001492924b 15. /build/src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88641 16. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 17. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 18. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 19. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 20. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 21. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 22. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 23. ? @ 0x00007fbc6213eac3 24. ? @ 0x00007fbc621d0850 2025.07.28 11:54:24.840970 [ 17255 ] {} TCPHandler: Code: 42. DB::Exception: Table function 'executable' requires minimum 3 arguments: script_name, format, structure, [input_query...]. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x000000000a06b56b 4. /build/src/TableFunctions/TableFunctionExecutable.cpp:98: DB::(anonymous namespace)::TableFunctionExecutable::parseArguments(std::shared_ptr const&, std::shared_ptr) @ 0x0000000011821d80 5. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:4834: DB::QueryAnalyzer::resolveTableFunction(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&, bool) @ 0x000000001401cb85 6. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5342: DB::QueryAnalyzer::resolveQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&) @ 0x00000000140452bf 7. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5597: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000140136f0 8. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000140127f9 9. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000014011fce 10. /build/src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000001406ce8a 11. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000014973b42 12. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000001497268d 13. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000014974d24 14. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001492924b 15. /build/src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88641 16. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 17. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 18. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 19. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 20. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 21. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 22. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 23. ? @ 0x00007fbc6213eac3 24. ? @ 0x00007fbc621d0850 2025.07.28 11:54:24.878197 [ 3961 ] {} test_13.rmt2 (7f9b740d-015c-470e-8cc6-8ba33be0dc63): auto DB::StorageReplicatedMergeTree::processQueueEntry(ReplicatedMergeTreeQueue::SelectedEntryPtr)::(anonymous class)::operator()(LogEntryPtr &) const: Code: 86. DB::HTTPException: Received error from remote server http://146b4357c08d:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Ftest%2F01165%2Ftest_13%2Frmt%2Freplicas%2F1&part=20250728_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.6.10636.altinitytest (altinity build)) '. (RECEIVED_ERROR_FROM_REMOTE_IO_SERVER), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.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 const&, int&&, String const&, unsigned long&&, String const&) @ 0x000000000feda8d9 4. /build/src/IO/HTTPCommon.cpp:104: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x000000000feda6e2 5. /build/src/IO/HTTPCommon.cpp:93: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x000000000feda537 6. /build/src/IO/ReadWriteBufferFromHTTP.cpp:277: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x000000001184a4c4 7. /build/src/IO/ReadWriteBufferFromHTTP.cpp:285: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x000000001184a615 8. /build/src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x000000001184ae59 9. /build/src/IO/ReadWriteBufferFromHTTP.cpp:472: void std::__function::__policy_invoker::__call_impl[abi:se190107]>(std::__function::__policy_storage const*) @ 0x000000001184cedd 10. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001184858b 11. /build/src/IO/ReadWriteBufferFromHTTP.cpp:465: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x000000001184bf0b 12. /build/src/IO/ReadBuffer.h:60: DB::ReadBuffer::next() @ 0x000000000a148c7b 13. /build/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) @ 0x0000000011849fb2 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]>&)>&, 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&) @ 0x0000000011841980 15. /build/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) @ 0x000000001621208e 16. /build/src/Storages/StorageReplicatedMergeTree.cpp:5228: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl[abi:se190107] const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000015f9a5fe 17. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000015ed8bfd 18. /build/src/Storages/StorageReplicatedMergeTree.cpp:2514: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x0000000015ec9aab 19. /build/src/Storages/StorageReplicatedMergeTree.cpp:2349: DB::StorageReplicatedMergeTree::executeLogEntry(DB::ReplicatedMergeTreeLogEntry&) @ 0x0000000015eba91b 20. /build/src/Storages/StorageReplicatedMergeTree.cpp:3876: bool std::__function::__policy_invoker&)>::__call_impl[abi:se190107])::$_1, bool (std::shared_ptr&)>>(std::__function::__policy_storage const*, std::shared_ptr&) @ 0x0000000015f9837e 21. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000165d6fc3 22. /build/src/Storages/StorageReplicatedMergeTree.cpp:3872: DB::StorageReplicatedMergeTree::processQueueEntry(std::shared_ptr) @ 0x0000000015efc18a 23. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001624c1b2 24. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000162f9c70 25. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x00000000162fa55a 26. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc6653 27. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000000fccc4c3 28. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc3d92 29. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fcca080 30. ? @ 0x00007fbc6213eac3 31. ? @ 0x00007fbc621d0850 (version 25.3.6.10636.altinitytest (altinity build)) 2025.07.28 11:54:25.048794 [ 5951 ] {5f5cac00-08d5-4bb2-9eab-f99920bd0d6a} executeQuery: Code: 1. DB::Exception: Lambda must have arguments and body. (UNSUPPORTED_METHOD) (version 25.3.6.10636.altinitytest (altinity build)) (from [::1]:48012) (comment: 02181_sql_user_defined_functions_invalid_lambda.sql) (query 1, line 1) (in query: CREATE FUNCTION 02181_invalid_lambda AS lambda(((x * 2) AS x_doubled) + x_doubled);), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000000a074fcb 4. /build/src/Functions/UserDefined/UserDefinedSQLFunctionFactory.cpp:60: DB::UserDefinedSQLFunctionFactory::checkCanBeRegistered(std::shared_ptr const&, String const&, DB::IAST const&) @ 0x0000000016eef724 5. /build/src/Functions/UserDefined/UserDefinedSQLFunctionFactory.cpp:135: DB::UserDefinedSQLFunctionFactory::registerFunction(std::shared_ptr const&, String const&, std::shared_ptr, bool, bool) @ 0x0000000016eefaa8 6. /build/src/Interpreters/InterpreterCreateFunctionQuery.cpp:52: DB::InterpreterCreateFunctionQuery::execute() @ 0x0000000014cf82df 7. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88dc9 8. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 9. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 10. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 11. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 12. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 13. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 14. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 15. ? @ 0x00007fbc6213eac3 16. ? @ 0x00007fbc621d0850 2025.07.28 11:54:25.055052 [ 5951 ] {} TCPHandler: Code: 1. DB::Exception: Lambda must have arguments and body. (UNSUPPORTED_METHOD), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000000a074fcb 4. /build/src/Functions/UserDefined/UserDefinedSQLFunctionFactory.cpp:60: DB::UserDefinedSQLFunctionFactory::checkCanBeRegistered(std::shared_ptr const&, String const&, DB::IAST const&) @ 0x0000000016eef724 5. /build/src/Functions/UserDefined/UserDefinedSQLFunctionFactory.cpp:135: DB::UserDefinedSQLFunctionFactory::registerFunction(std::shared_ptr const&, String const&, std::shared_ptr, bool, bool) @ 0x0000000016eefaa8 6. /build/src/Interpreters/InterpreterCreateFunctionQuery.cpp:52: DB::InterpreterCreateFunctionQuery::execute() @ 0x0000000014cf82df 7. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88dc9 8. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 9. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 10. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 11. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 12. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 13. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 14. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 15. ? @ 0x00007fbc6213eac3 16. ? @ 0x00007fbc621d0850 2025.07.28 11:54:25.088181 [ 5951 ] {a41a8b89-e938-4b90-8fdd-c750ced9d851} executeQuery: Code: 1. DB::Exception: Lambda must have arguments and body. (UNSUPPORTED_METHOD) (version 25.3.6.10636.altinitytest (altinity build)) (from [::1]:48012) (comment: 02181_sql_user_defined_functions_invalid_lambda.sql) (query 2, line 2) (in query: CREATE FUNCTION 02181_invalid_lambda AS lambda(x);), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000000a074fcb 4. /build/src/Functions/UserDefined/UserDefinedSQLFunctionFactory.cpp:60: DB::UserDefinedSQLFunctionFactory::checkCanBeRegistered(std::shared_ptr const&, String const&, DB::IAST const&) @ 0x0000000016eef724 5. /build/src/Functions/UserDefined/UserDefinedSQLFunctionFactory.cpp:135: DB::UserDefinedSQLFunctionFactory::registerFunction(std::shared_ptr const&, String const&, std::shared_ptr, bool, bool) @ 0x0000000016eefaa8 6. /build/src/Interpreters/InterpreterCreateFunctionQuery.cpp:52: DB::InterpreterCreateFunctionQuery::execute() @ 0x0000000014cf82df 7. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88dc9 8. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 9. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 10. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 11. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 12. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 13. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 14. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 15. ? @ 0x00007fbc6213eac3 16. ? @ 0x00007fbc621d0850 2025.07.28 11:54:25.097751 [ 5951 ] {} TCPHandler: Code: 1. DB::Exception: Lambda must have arguments and body. (UNSUPPORTED_METHOD), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000000a074fcb 4. /build/src/Functions/UserDefined/UserDefinedSQLFunctionFactory.cpp:60: DB::UserDefinedSQLFunctionFactory::checkCanBeRegistered(std::shared_ptr const&, String const&, DB::IAST const&) @ 0x0000000016eef724 5. /build/src/Functions/UserDefined/UserDefinedSQLFunctionFactory.cpp:135: DB::UserDefinedSQLFunctionFactory::registerFunction(std::shared_ptr const&, String const&, std::shared_ptr, bool, bool) @ 0x0000000016eefaa8 6. /build/src/Interpreters/InterpreterCreateFunctionQuery.cpp:52: DB::InterpreterCreateFunctionQuery::execute() @ 0x0000000014cf82df 7. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88dc9 8. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 9. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 10. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 11. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 12. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 13. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 14. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 15. ? @ 0x00007fbc6213eac3 16. ? @ 0x00007fbc621d0850 2025.07.28 11:54:25.210495 [ 5951 ] {f14a374a-2f1b-4b36-a406-cfc61133b6d0} executeQuery: Code: 1. DB::Exception: Lambda must have arguments and body. (UNSUPPORTED_METHOD) (version 25.3.6.10636.altinitytest (altinity build)) (from [::1]:48012) (comment: 02181_sql_user_defined_functions_invalid_lambda.sql) (query 3, line 3) (in query: CREATE FUNCTION 02181_invalid_lambda AS lambda();), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000000a074fcb 4. /build/src/Functions/UserDefined/UserDefinedSQLFunctionFactory.cpp:60: DB::UserDefinedSQLFunctionFactory::checkCanBeRegistered(std::shared_ptr const&, String const&, DB::IAST const&) @ 0x0000000016eef724 5. /build/src/Functions/UserDefined/UserDefinedSQLFunctionFactory.cpp:135: DB::UserDefinedSQLFunctionFactory::registerFunction(std::shared_ptr const&, String const&, std::shared_ptr, bool, bool) @ 0x0000000016eefaa8 6. /build/src/Interpreters/InterpreterCreateFunctionQuery.cpp:52: DB::InterpreterCreateFunctionQuery::execute() @ 0x0000000014cf82df 7. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88dc9 8. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 9. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 10. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 11. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 12. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 13. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 14. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 15. ? @ 0x00007fbc6213eac3 16. ? @ 0x00007fbc621d0850 2025.07.28 11:54:25.213982 [ 5951 ] {} TCPHandler: Code: 1. DB::Exception: Lambda must have arguments and body. (UNSUPPORTED_METHOD), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000000a074fcb 4. /build/src/Functions/UserDefined/UserDefinedSQLFunctionFactory.cpp:60: DB::UserDefinedSQLFunctionFactory::checkCanBeRegistered(std::shared_ptr const&, String const&, DB::IAST const&) @ 0x0000000016eef724 5. /build/src/Functions/UserDefined/UserDefinedSQLFunctionFactory.cpp:135: DB::UserDefinedSQLFunctionFactory::registerFunction(std::shared_ptr const&, String const&, std::shared_ptr, bool, bool) @ 0x0000000016eefaa8 6. /build/src/Interpreters/InterpreterCreateFunctionQuery.cpp:52: DB::InterpreterCreateFunctionQuery::execute() @ 0x0000000014cf82df 7. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88dc9 8. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 9. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 10. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 11. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 12. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 13. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 14. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 15. ? @ 0x00007fbc6213eac3 16. ? @ 0x00007fbc621d0850 2025.07.28 11:54:25.319422 [ 5951 ] {1a06b851-fc39-4055-94c7-7d43d50c5a03} executeQuery: Code: 1. DB::Exception: Lambda must have arguments and body. (UNSUPPORTED_METHOD) (version 25.3.6.10636.altinitytest (altinity build)) (from [::1]:48012) (comment: 02181_sql_user_defined_functions_invalid_lambda.sql) (query 4, line 4) (in query: CREATE FUNCTION 02181_invalid_lambda AS lambda(tuple(x)) --{serverError UNSUPPORTED_METHOD} ), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000000a074fcb 4. /build/src/Functions/UserDefined/UserDefinedSQLFunctionFactory.cpp:60: DB::UserDefinedSQLFunctionFactory::checkCanBeRegistered(std::shared_ptr const&, String const&, DB::IAST const&) @ 0x0000000016eef724 5. /build/src/Functions/UserDefined/UserDefinedSQLFunctionFactory.cpp:135: DB::UserDefinedSQLFunctionFactory::registerFunction(std::shared_ptr const&, String const&, std::shared_ptr, bool, bool) @ 0x0000000016eefaa8 6. /build/src/Interpreters/InterpreterCreateFunctionQuery.cpp:52: DB::InterpreterCreateFunctionQuery::execute() @ 0x0000000014cf82df 7. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88dc9 8. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 9. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 10. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 11. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 12. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 13. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 14. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 15. ? @ 0x00007fbc6213eac3 16. ? @ 0x00007fbc621d0850 2025.07.28 11:54:25.329548 [ 5951 ] {} TCPHandler: Code: 1. DB::Exception: Lambda must have arguments and body. (UNSUPPORTED_METHOD), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000000a074fcb 4. /build/src/Functions/UserDefined/UserDefinedSQLFunctionFactory.cpp:60: DB::UserDefinedSQLFunctionFactory::checkCanBeRegistered(std::shared_ptr const&, String const&, DB::IAST const&) @ 0x0000000016eef724 5. /build/src/Functions/UserDefined/UserDefinedSQLFunctionFactory.cpp:135: DB::UserDefinedSQLFunctionFactory::registerFunction(std::shared_ptr const&, String const&, std::shared_ptr, bool, bool) @ 0x0000000016eefaa8 6. /build/src/Interpreters/InterpreterCreateFunctionQuery.cpp:52: DB::InterpreterCreateFunctionQuery::execute() @ 0x0000000014cf82df 7. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88dc9 8. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 9. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 10. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 11. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 12. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 13. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 14. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 15. ? @ 0x00007fbc6213eac3 16. ? @ 0x00007fbc621d0850 2025.07.28 11:54:25.392333 [ 17371 ] {2cc5bd69-0ab9-48cc-905f-90bbce1448b6} executeQuery: Code: 153. DB::Exception: Division by zero: while executing 'FUNCTION modulo(1_UInt8 :: 1, modulo(plus(__table1.number, 500_UInt16), 1000_UInt16) :: 2) -> modulo(1_UInt8, modulo(plus(__table1.number, 500_UInt16), 1000_UInt16)) UInt16 : 3'. (ILLEGAL_DIVISION) (version 25.3.6.10636.altinitytest (altinity build)) (from [::1]:47930) (comment: 00093_union_race_conditions_4.sh) (query 1, line 1) (in query: SELECT 1 % ((number + 500) % 1000) FROM numbers_mt(1000);), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000000a074fcb 4. /build/src/Functions/DivisionUtils.h:26: void DB::impl_::BinaryOperation, unsigned short>::process<(DB::impl_::OpCase)1>(char8_t const*, unsigned short const*, unsigned short*, unsigned long, DB::PODArray, 63ul, 64ul> const*) @ 0x000000000d184621 5. /build/src/Functions/FunctionBinaryArithmetic.h:2338: COW::immutable_ptr DB::FunctionBinaryArithmetic::executeNumeric, DB::DataTypeNumber>(std::vector> const&, DB::DataTypeNumber const&, DB::DataTypeNumber const&, DB::PODArray, 63ul, 64ul> const*) const @ 0x000000000d3a6416 6. /build/src/Functions/FunctionBinaryArithmetic.h:2508: 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&&) @ 0x000000000d3a4a68 7. /build/src/Functions/FunctionBinaryArithmetic.h:846: 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&&) @ 0x000000000d3a3ec7 8. /build/src/Functions/FunctionBinaryArithmetic.h:844: DB::FunctionBinaryArithmetic::executeImpl2(std::vector> const&, std::shared_ptr const&, unsigned long, DB::PODArray, 63ul, 64ul> const*) const @ 0x000000000d3a03c5 9. /build/src/Functions/FunctionBinaryArithmetic.h:2410: DB::FunctionBinaryArithmetic::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000d39e94c 10. /build/src/Functions/FunctionBinaryArithmetic.h:2645: DB::FunctionBinaryArithmeticWithConstants::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000d39dbd4 11. /build/src/Functions/IFunctionAdaptors.cpp:10: DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000012d995fa 12. /build/src/Functions/IFunction.cpp:353: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d93b52 13. /build/src/Functions/IFunction.cpp:420: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d95059 14. /build/src/Functions/IFunction.cpp:498: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d95c72 15. /build/src/Interpreters/ExpressionActions.cpp:636: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x00000000145176f3 16. /build/src/Processors/Transforms/ExpressionTransform.cpp:25: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x0000000016c0b34c 17. /build/src/Processors/ISimpleTransform.h:33: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000011a9a453 18. /build/src/Processors/ISimpleTransform.cpp:89: DB::ISimpleTransform::work() @ 0x000000001699fca0 19. /build/src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x00000000169bd00f 20. /build/src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x00000000169b2105 21. /build/src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeSingleThread(unsigned long) @ 0x00000000169b23be 22. /build/src/Processors/Executors/PipelineExecutor.cpp:454: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x00000000169b0be7 23. /build/src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x00000000169b03f4 24. /build/src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:se190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169bfeab 25. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc3d92 26. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fcca080 27. ? @ 0x00007fbc6213eac3 28. ? @ 0x00007fbc621d0850 2025.07.28 11:54:25.415437 [ 17371 ] {} TCPHandler: Code: 153. DB::Exception: Division by zero: while executing 'FUNCTION modulo(1_UInt8 :: 1, modulo(plus(__table1.number, 500_UInt16), 1000_UInt16) :: 2) -> modulo(1_UInt8, modulo(plus(__table1.number, 500_UInt16), 1000_UInt16)) UInt16 : 3'. (ILLEGAL_DIVISION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000000a074fcb 4. /build/src/Functions/DivisionUtils.h:26: void DB::impl_::BinaryOperation, unsigned short>::process<(DB::impl_::OpCase)1>(char8_t const*, unsigned short const*, unsigned short*, unsigned long, DB::PODArray, 63ul, 64ul> const*) @ 0x000000000d184621 5. /build/src/Functions/FunctionBinaryArithmetic.h:2338: COW::immutable_ptr DB::FunctionBinaryArithmetic::executeNumeric, DB::DataTypeNumber>(std::vector> const&, DB::DataTypeNumber const&, DB::DataTypeNumber const&, DB::PODArray, 63ul, 64ul> const*) const @ 0x000000000d3a6416 6. /build/src/Functions/FunctionBinaryArithmetic.h:2508: 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&&) @ 0x000000000d3a4a68 7. /build/src/Functions/FunctionBinaryArithmetic.h:846: 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&&) @ 0x000000000d3a3ec7 8. /build/src/Functions/FunctionBinaryArithmetic.h:844: DB::FunctionBinaryArithmetic::executeImpl2(std::vector> const&, std::shared_ptr const&, unsigned long, DB::PODArray, 63ul, 64ul> const*) const @ 0x000000000d3a03c5 9. /build/src/Functions/FunctionBinaryArithmetic.h:2410: DB::FunctionBinaryArithmetic::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000d39e94c 10. /build/src/Functions/FunctionBinaryArithmetic.h:2645: DB::FunctionBinaryArithmeticWithConstants::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000d39dbd4 11. /build/src/Functions/IFunctionAdaptors.cpp:10: DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000012d995fa 12. /build/src/Functions/IFunction.cpp:353: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d93b52 13. /build/src/Functions/IFunction.cpp:420: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d95059 14. /build/src/Functions/IFunction.cpp:498: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d95c72 15. /build/src/Interpreters/ExpressionActions.cpp:636: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x00000000145176f3 16. /build/src/Processors/Transforms/ExpressionTransform.cpp:25: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x0000000016c0b34c 17. /build/src/Processors/ISimpleTransform.h:33: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000011a9a453 18. /build/src/Processors/ISimpleTransform.cpp:89: DB::ISimpleTransform::work() @ 0x000000001699fca0 19. /build/src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x00000000169bd00f 20. /build/src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x00000000169b2105 21. /build/src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeSingleThread(unsigned long) @ 0x00000000169b23be 22. /build/src/Processors/Executors/PipelineExecutor.cpp:454: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x00000000169b0be7 23. /build/src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x00000000169b03f4 24. /build/src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:se190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169bfeab 25. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc3d92 26. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fcca080 27. ? @ 0x00007fbc6213eac3 28. ? @ 0x00007fbc621d0850 Job's origin stack trace: 0. /build/src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000000fc33b84 1. /build/src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000000fcc2ea7 2. /build/src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fcc535c 3. /build/src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000000fcc584d 4. /build/src/Common/ThreadPool.h:279: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x00000000169bf193 5. /build/src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x00000000169bf518 6. /build/src/Server/TCPHandler.cpp:1237: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x00000000168f1525 7. /build/src/Server/TCPHandler.cpp:678: DB::TCPHandler::runImpl() @ 0x00000000168e68e5 8. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 9. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 10. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 11. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 12. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 13. ? @ 0x00007fbc6213eac3 14. ? @ 0x00007fbc621d0850 2025.07.28 11:54:25.790405 [ 3974 ] {} test_13.rmt2 (7f9b740d-015c-470e-8cc6-8ba33be0dc63): auto DB::StorageReplicatedMergeTree::processQueueEntry(ReplicatedMergeTreeQueue::SelectedEntryPtr)::(anonymous class)::operator()(LogEntryPtr &) const: Code: 86. DB::HTTPException: Received error from remote server http://146b4357c08d:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Ftest%2F01165%2Ftest_13%2Frmt%2Freplicas%2F1&part=20250728_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.6.10636.altinitytest (altinity build)) '. (RECEIVED_ERROR_FROM_REMOTE_IO_SERVER), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.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 const&, int&&, String const&, unsigned long&&, String const&) @ 0x000000000feda8d9 4. /build/src/IO/HTTPCommon.cpp:104: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x000000000feda6e2 5. /build/src/IO/HTTPCommon.cpp:93: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x000000000feda537 6. /build/src/IO/ReadWriteBufferFromHTTP.cpp:277: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x000000001184a4c4 7. /build/src/IO/ReadWriteBufferFromHTTP.cpp:285: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x000000001184a615 8. /build/src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x000000001184ae59 9. /build/src/IO/ReadWriteBufferFromHTTP.cpp:472: void std::__function::__policy_invoker::__call_impl[abi:se190107]>(std::__function::__policy_storage const*) @ 0x000000001184cedd 10. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001184858b 11. /build/src/IO/ReadWriteBufferFromHTTP.cpp:465: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x000000001184bf0b 12. /build/src/IO/ReadBuffer.h:60: DB::ReadBuffer::next() @ 0x000000000a148c7b 13. /build/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) @ 0x0000000011849fb2 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]>&)>&, 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&) @ 0x0000000011841980 15. /build/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) @ 0x000000001621208e 16. /build/src/Storages/StorageReplicatedMergeTree.cpp:5228: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl[abi:se190107] const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000015f9a5fe 17. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000015ed8bfd 18. /build/src/Storages/StorageReplicatedMergeTree.cpp:2514: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x0000000015ec9aab 19. /build/src/Storages/StorageReplicatedMergeTree.cpp:2349: DB::StorageReplicatedMergeTree::executeLogEntry(DB::ReplicatedMergeTreeLogEntry&) @ 0x0000000015eba91b 20. /build/src/Storages/StorageReplicatedMergeTree.cpp:3876: bool std::__function::__policy_invoker&)>::__call_impl[abi:se190107])::$_1, bool (std::shared_ptr&)>>(std::__function::__policy_storage const*, std::shared_ptr&) @ 0x0000000015f9837e 21. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000165d6fc3 22. /build/src/Storages/StorageReplicatedMergeTree.cpp:3872: DB::StorageReplicatedMergeTree::processQueueEntry(std::shared_ptr) @ 0x0000000015efc18a 23. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001624c1b2 24. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000162f9c70 25. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x00000000162fa55a 26. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc6653 27. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000000fccc4c3 28. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc3d92 29. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fcca080 30. ? @ 0x00007fbc6213eac3 31. ? @ 0x00007fbc621d0850 (version 25.3.6.10636.altinitytest (altinity build)) 2025.07.28 11:54:26.321819 [ 3969 ] {} test_13.rmt2 (7f9b740d-015c-470e-8cc6-8ba33be0dc63): auto DB::StorageReplicatedMergeTree::processQueueEntry(ReplicatedMergeTreeQueue::SelectedEntryPtr)::(anonymous class)::operator()(LogEntryPtr &) const: Code: 86. DB::HTTPException: Received error from remote server http://146b4357c08d:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Ftest%2F01165%2Ftest_13%2Frmt%2Freplicas%2F1&part=20250728_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.6.10636.altinitytest (altinity build)) '. (RECEIVED_ERROR_FROM_REMOTE_IO_SERVER), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.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 const&, int&&, String const&, unsigned long&&, String const&) @ 0x000000000feda8d9 4. /build/src/IO/HTTPCommon.cpp:104: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x000000000feda6e2 5. /build/src/IO/HTTPCommon.cpp:93: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x000000000feda537 6. /build/src/IO/ReadWriteBufferFromHTTP.cpp:277: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x000000001184a4c4 7. /build/src/IO/ReadWriteBufferFromHTTP.cpp:285: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x000000001184a615 8. /build/src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x000000001184ae59 9. /build/src/IO/ReadWriteBufferFromHTTP.cpp:472: void std::__function::__policy_invoker::__call_impl[abi:se190107]>(std::__function::__policy_storage const*) @ 0x000000001184cedd 10. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001184858b 11. /build/src/IO/ReadWriteBufferFromHTTP.cpp:465: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x000000001184bf0b 12. /build/src/IO/ReadBuffer.h:60: DB::ReadBuffer::next() @ 0x000000000a148c7b 13. /build/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) @ 0x0000000011849fb2 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]>&)>&, 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&) @ 0x0000000011841980 15. /build/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) @ 0x000000001621208e 16. /build/src/Storages/StorageReplicatedMergeTree.cpp:5228: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl[abi:se190107] const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000015f9a5fe 17. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000015ed8bfd 18. /build/src/Storages/StorageReplicatedMergeTree.cpp:2514: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x0000000015ec9aab 19. /build/src/Storages/StorageReplicatedMergeTree.cpp:2349: DB::StorageReplicatedMergeTree::executeLogEntry(DB::ReplicatedMergeTreeLogEntry&) @ 0x0000000015eba91b 20. /build/src/Storages/StorageReplicatedMergeTree.cpp:3876: bool std::__function::__policy_invoker&)>::__call_impl[abi:se190107])::$_1, bool (std::shared_ptr&)>>(std::__function::__policy_storage const*, std::shared_ptr&) @ 0x0000000015f9837e 21. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000165d6fc3 22. /build/src/Storages/StorageReplicatedMergeTree.cpp:3872: DB::StorageReplicatedMergeTree::processQueueEntry(std::shared_ptr) @ 0x0000000015efc18a 23. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001624c1b2 24. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000162f9c70 25. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x00000000162fa55a 26. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc6653 27. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000000fccc4c3 28. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc3d92 29. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fcca080 30. ? @ 0x00007fbc6213eac3 31. ? @ 0x00007fbc621d0850 (version 25.3.6.10636.altinitytest (altinity build)) 2025.07.28 11:54:26.414233 [ 17287 ] {73ab4ce9-a80d-4ba5-9681-23763a957cdb} executeQuery: Code: 36. DB::Exception: Frame start offset 2 FOLLOWING does not precede the frame end offset 0 FOLLOWING. (BAD_ARGUMENTS) (version 25.3.6.10636.altinitytest (altinity build)) (from [::1]:47980) (comment: 01571_window_functions.sql) (query 10, line 32) (in query: -- signed and unsigned in offset do not cause logical error select count() over (rows between 2 following and 1 + -1 following) FROM numbers(10);), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, DB::Field const&, char const (&) [10], DB::Field const&, char const (&) [10]) @ 0x0000000014c47f6b 4. /build/src/Interpreters/WindowDescription.cpp:179: DB::WindowFrame::checkValid() const @ 0x0000000014c47be9 5. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:2565: DB::QueryAnalyzer::resolveWindow(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000001403ef58 6. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3291: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000014031889 7. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3838: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000014019a9e 8. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3980: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000014018e31 9. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:4304: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000014042fa7 10. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5605: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000014013749 11. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000140127f9 12. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000014011fce 13. /build/src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000001406ce8a 14. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000014973b42 15. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000001497268d 16. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000014974d24 17. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001492924b 18. /build/src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88641 19. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 20. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 21. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 22. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 23. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 24. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 25. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 26. ? @ 0x00007fbc6213eac3 27. ? @ 0x00007fbc621d0850 2025.07.28 11:54:26.417246 [ 17287 ] {} TCPHandler: Code: 36. DB::Exception: Frame start offset 2 FOLLOWING does not precede the frame end offset 0 FOLLOWING. (BAD_ARGUMENTS), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, DB::Field const&, char const (&) [10], DB::Field const&, char const (&) [10]) @ 0x0000000014c47f6b 4. /build/src/Interpreters/WindowDescription.cpp:179: DB::WindowFrame::checkValid() const @ 0x0000000014c47be9 5. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:2565: DB::QueryAnalyzer::resolveWindow(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000001403ef58 6. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3291: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000014031889 7. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3838: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000014019a9e 8. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3980: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000014018e31 9. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:4304: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000014042fa7 10. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5605: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000014013749 11. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000140127f9 12. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000014011fce 13. /build/src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000001406ce8a 14. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000014973b42 15. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000001497268d 16. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000014974d24 17. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001492924b 18. /build/src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88641 19. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 20. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 21. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 22. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 23. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 24. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 25. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 26. ? @ 0x00007fbc6213eac3 27. ? @ 0x00007fbc621d0850 2025.07.28 11:54:26.641723 [ 17255 ] {1847c0dd-c128-4694-b25f-b22aff48c56f} executeQuery: Code: 48. DB::Exception: Only `hash` join supports multiple ORs for keys in JOIN ON section. (NOT_IMPLEMENTED) (version 25.3.6.10636.altinitytest (altinity build)) (from [::1]:48050) (comment: 01660_join_or_subqueries.sql) (query 11, line 15) (in query: select a1 from tab1 any left join (select * from tab2) on b1 = a2 or b2 = a1;), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000000a074fcb 4. /build/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) @ 0x00000000149c5d03 5. /build/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) @ 0x0000000016de9821 6. /build/src/Processors/QueryPlan/Optimizations/optimizeJoin.cpp:251: DB::QueryPlanOptimizations::convertLogicalJoinToPhysical(DB::QueryPlan::Node&, std::list>&, DB::QueryPlanOptimizationSettings const&, std::optional) @ 0x0000000016eb5ce9 7. /build/src/Processors/QueryPlan/Optimizations/optimizeTree.cpp:158: DB::QueryPlanOptimizations::optimizeTreeSecondPass(DB::QueryPlanOptimizationSettings const&, DB::QueryPlan::Node&, std::list>&) @ 0x0000000016ead357 8. /build/src/Processors/QueryPlan/QueryPlan.cpp:487: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x0000000016e0055c 9. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:275: DB::InterpreterSelectQueryAnalyzer::buildQueryPipeline() @ 0x0000000014974614 10. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:242: DB::InterpreterSelectQueryAnalyzer::execute() @ 0x000000001497439e 11. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88dc9 12. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 13. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 14. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 15. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 16. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 17. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 18. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 19. ? @ 0x00007fbc6213eac3 20. ? @ 0x00007fbc621d0850 2025.07.28 11:54:26.662283 [ 17255 ] {} 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. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000000a074fcb 4. /build/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) @ 0x00000000149c5d03 5. /build/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) @ 0x0000000016de9821 6. /build/src/Processors/QueryPlan/Optimizations/optimizeJoin.cpp:251: DB::QueryPlanOptimizations::convertLogicalJoinToPhysical(DB::QueryPlan::Node&, std::list>&, DB::QueryPlanOptimizationSettings const&, std::optional) @ 0x0000000016eb5ce9 7. /build/src/Processors/QueryPlan/Optimizations/optimizeTree.cpp:158: DB::QueryPlanOptimizations::optimizeTreeSecondPass(DB::QueryPlanOptimizationSettings const&, DB::QueryPlan::Node&, std::list>&) @ 0x0000000016ead357 8. /build/src/Processors/QueryPlan/QueryPlan.cpp:487: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x0000000016e0055c 9. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:275: DB::InterpreterSelectQueryAnalyzer::buildQueryPipeline() @ 0x0000000014974614 10. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:242: DB::InterpreterSelectQueryAnalyzer::execute() @ 0x000000001497439e 11. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88dc9 12. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 13. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 14. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 15. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 16. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 17. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 18. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 19. ? @ 0x00007fbc6213eac3 20. ? @ 0x00007fbc621d0850 2025.07.28 11:54:26.677401 [ 3967 ] {} test_13.rmt2 (7f9b740d-015c-470e-8cc6-8ba33be0dc63): auto DB::StorageReplicatedMergeTree::processQueueEntry(ReplicatedMergeTreeQueue::SelectedEntryPtr)::(anonymous class)::operator()(LogEntryPtr &) const: Code: 86. DB::HTTPException: Received error from remote server http://146b4357c08d:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Ftest%2F01165%2Ftest_13%2Frmt%2Freplicas%2F1&part=20250728_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.6.10636.altinitytest (altinity build)) '. (RECEIVED_ERROR_FROM_REMOTE_IO_SERVER), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.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 const&, int&&, String const&, unsigned long&&, String const&) @ 0x000000000feda8d9 4. /build/src/IO/HTTPCommon.cpp:104: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x000000000feda6e2 5. /build/src/IO/HTTPCommon.cpp:93: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x000000000feda537 6. /build/src/IO/ReadWriteBufferFromHTTP.cpp:277: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x000000001184a4c4 7. /build/src/IO/ReadWriteBufferFromHTTP.cpp:285: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x000000001184a615 8. /build/src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x000000001184ae59 9. /build/src/IO/ReadWriteBufferFromHTTP.cpp:472: void std::__function::__policy_invoker::__call_impl[abi:se190107]>(std::__function::__policy_storage const*) @ 0x000000001184cedd 10. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001184858b 11. /build/src/IO/ReadWriteBufferFromHTTP.cpp:465: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x000000001184bf0b 12. /build/src/IO/ReadBuffer.h:60: DB::ReadBuffer::next() @ 0x000000000a148c7b 13. /build/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) @ 0x0000000011849fb2 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]>&)>&, 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&) @ 0x0000000011841980 15. /build/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) @ 0x000000001621208e 16. /build/src/Storages/StorageReplicatedMergeTree.cpp:5228: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl[abi:se190107] const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000015f9a5fe 17. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000015ed8bfd 18. /build/src/Storages/StorageReplicatedMergeTree.cpp:2514: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x0000000015ec9aab 19. /build/src/Storages/StorageReplicatedMergeTree.cpp:2349: DB::StorageReplicatedMergeTree::executeLogEntry(DB::ReplicatedMergeTreeLogEntry&) @ 0x0000000015eba91b 20. /build/src/Storages/StorageReplicatedMergeTree.cpp:3876: bool std::__function::__policy_invoker&)>::__call_impl[abi:se190107])::$_1, bool (std::shared_ptr&)>>(std::__function::__policy_storage const*, std::shared_ptr&) @ 0x0000000015f9837e 21. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000165d6fc3 22. /build/src/Storages/StorageReplicatedMergeTree.cpp:3872: DB::StorageReplicatedMergeTree::processQueueEntry(std::shared_ptr) @ 0x0000000015efc18a 23. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001624c1b2 24. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000162f9c70 25. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x00000000162fa55a 26. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc6653 27. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000000fccc4c3 28. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc3d92 29. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fcca080 30. ? @ 0x00007fbc6213eac3 31. ? @ 0x00007fbc621d0850 (version 25.3.6.10636.altinitytest (altinity build)) 2025.07.28 11:54:26.932579 [ 3965 ] {} test_13.rmt2 (7f9b740d-015c-470e-8cc6-8ba33be0dc63): auto DB::StorageReplicatedMergeTree::processQueueEntry(ReplicatedMergeTreeQueue::SelectedEntryPtr)::(anonymous class)::operator()(LogEntryPtr &) const: Code: 86. DB::HTTPException: Received error from remote server http://146b4357c08d:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Ftest%2F01165%2Ftest_13%2Frmt%2Freplicas%2F1&part=20250728_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.6.10636.altinitytest (altinity build)) '. (RECEIVED_ERROR_FROM_REMOTE_IO_SERVER), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.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 const&, int&&, String const&, unsigned long&&, String const&) @ 0x000000000feda8d9 4. /build/src/IO/HTTPCommon.cpp:104: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x000000000feda6e2 5. /build/src/IO/HTTPCommon.cpp:93: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x000000000feda537 6. /build/src/IO/ReadWriteBufferFromHTTP.cpp:277: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x000000001184a4c4 7. /build/src/IO/ReadWriteBufferFromHTTP.cpp:285: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x000000001184a615 8. /build/src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x000000001184ae59 9. /build/src/IO/ReadWriteBufferFromHTTP.cpp:472: void std::__function::__policy_invoker::__call_impl[abi:se190107]>(std::__function::__policy_storage const*) @ 0x000000001184cedd 10. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001184858b 11. /build/src/IO/ReadWriteBufferFromHTTP.cpp:465: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x000000001184bf0b 12. /build/src/IO/ReadBuffer.h:60: DB::ReadBuffer::next() @ 0x000000000a148c7b 13. /build/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) @ 0x0000000011849fb2 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]>&)>&, 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&) @ 0x0000000011841980 15. /build/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) @ 0x000000001621208e 16. /build/src/Storages/StorageReplicatedMergeTree.cpp:5228: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl[abi:se190107] const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000015f9a5fe 17. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000015ed8bfd 18. /build/src/Storages/StorageReplicatedMergeTree.cpp:2514: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x0000000015ec9aab 19. /build/src/Storages/StorageReplicatedMergeTree.cpp:2349: DB::StorageReplicatedMergeTree::executeLogEntry(DB::ReplicatedMergeTreeLogEntry&) @ 0x0000000015eba91b 20. /build/src/Storages/StorageReplicatedMergeTree.cpp:3876: bool std::__function::__policy_invoker&)>::__call_impl[abi:se190107])::$_1, bool (std::shared_ptr&)>>(std::__function::__policy_storage const*, std::shared_ptr&) @ 0x0000000015f9837e 21. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000165d6fc3 22. /build/src/Storages/StorageReplicatedMergeTree.cpp:3872: DB::StorageReplicatedMergeTree::processQueueEntry(std::shared_ptr) @ 0x0000000015efc18a 23. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001624c1b2 24. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000162f9c70 25. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x00000000162fa55a 26. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc6653 27. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000000fccc4c3 28. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc3d92 29. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fcca080 30. ? @ 0x00007fbc6213eac3 31. ? @ 0x00007fbc621d0850 (version 25.3.6.10636.altinitytest (altinity build)) 2025.07.28 11:54:27.266192 [ 3536 ] {} 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. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000fccaeeb 4. /build/src/Common/ThreadPool.cpp:275: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000fccc813 5. /build/src/Common/ThreadPool.cpp:323: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fcc7bbc 6. /build/src/Common/ThreadPool.cpp:494: ThreadPoolImpl>::scheduleOrThrowOnError(std::function, Priority) @ 0x000000000fcc7a0e 7. /build/src/Common/threadPoolCallbackRunner.h:188: DB::ThreadPoolCallbackRunnerLocal>, std::function>::operator()(std::function&&, Priority, std::optional) @ 0x00000000119df78e 8. /build/src/Interpreters/DatabaseCatalog.cpp:1360: DB::DatabaseCatalog::dropTablesParallel(std::vector, std::allocator>>) @ 0x00000000144fcff9 9. /build/src/Interpreters/DatabaseCatalog.cpp:1382: DB::DatabaseCatalog::dropTableDataTask() @ 0x00000000144fd4fc 10. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000139630d4 11. /build/src/Core/BackgroundSchedulePool.cpp:308: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001396616a 12. /build/src/Core/BackgroundSchedulePool.cpp:171: void std::__function::__policy_invoker::__call_impl[abi:se190107]::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_1>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_1&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001396690a 13. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc3d92 14. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fcca080 15. ? @ 0x00007fbc6213eac3 16. ? @ 0x00007fbc621d0850 (version 25.3.6.10636.altinitytest (altinity build)) 2025.07.28 11:54:27.453234 [ 3970 ] {} test_13.rmt2 (7f9b740d-015c-470e-8cc6-8ba33be0dc63): auto DB::StorageReplicatedMergeTree::processQueueEntry(ReplicatedMergeTreeQueue::SelectedEntryPtr)::(anonymous class)::operator()(LogEntryPtr &) const: Code: 86. DB::HTTPException: Received error from remote server http://146b4357c08d:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Ftest%2F01165%2Ftest_13%2Frmt%2Freplicas%2F1&part=20250728_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.6.10636.altinitytest (altinity build)) '. (RECEIVED_ERROR_FROM_REMOTE_IO_SERVER), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.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 const&, int&&, String const&, unsigned long&&, String const&) @ 0x000000000feda8d9 4. /build/src/IO/HTTPCommon.cpp:104: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x000000000feda6e2 5. /build/src/IO/HTTPCommon.cpp:93: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x000000000feda537 6. /build/src/IO/ReadWriteBufferFromHTTP.cpp:277: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x000000001184a4c4 7. /build/src/IO/ReadWriteBufferFromHTTP.cpp:285: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x000000001184a615 8. /build/src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x000000001184ae59 9. /build/src/IO/ReadWriteBufferFromHTTP.cpp:472: void std::__function::__policy_invoker::__call_impl[abi:se190107]>(std::__function::__policy_storage const*) @ 0x000000001184cedd 10. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001184858b 11. /build/src/IO/ReadWriteBufferFromHTTP.cpp:465: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x000000001184bf0b 12. /build/src/IO/ReadBuffer.h:60: DB::ReadBuffer::next() @ 0x000000000a148c7b 13. /build/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) @ 0x0000000011849fb2 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]>&)>&, 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&) @ 0x0000000011841980 15. /build/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) @ 0x000000001621208e 16. /build/src/Storages/StorageReplicatedMergeTree.cpp:5228: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl[abi:se190107] const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000015f9a5fe 17. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000015ed8bfd 18. /build/src/Storages/StorageReplicatedMergeTree.cpp:2514: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x0000000015ec9aab 19. /build/src/Storages/StorageReplicatedMergeTree.cpp:2349: DB::StorageReplicatedMergeTree::executeLogEntry(DB::ReplicatedMergeTreeLogEntry&) @ 0x0000000015eba91b 20. /build/src/Storages/StorageReplicatedMergeTree.cpp:3876: bool std::__function::__policy_invoker&)>::__call_impl[abi:se190107])::$_1, bool (std::shared_ptr&)>>(std::__function::__policy_storage const*, std::shared_ptr&) @ 0x0000000015f9837e 21. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000165d6fc3 22. /build/src/Storages/StorageReplicatedMergeTree.cpp:3872: DB::StorageReplicatedMergeTree::processQueueEntry(std::shared_ptr) @ 0x0000000015efc18a 23. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001624c1b2 24. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000162f9c70 25. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x00000000162fa55a 26. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc6653 27. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000000fccc4c3 28. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc3d92 29. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fcca080 30. ? @ 0x00007fbc6213eac3 31. ? @ 0x00007fbc621d0850 (version 25.3.6.10636.altinitytest (altinity build)) 2025.07.28 11:54:27.701217 [ 3964 ] {} test_13.rmt2 (7f9b740d-015c-470e-8cc6-8ba33be0dc63): auto DB::StorageReplicatedMergeTree::processQueueEntry(ReplicatedMergeTreeQueue::SelectedEntryPtr)::(anonymous class)::operator()(LogEntryPtr &) const: Code: 86. DB::HTTPException: Received error from remote server http://146b4357c08d:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Ftest%2F01165%2Ftest_13%2Frmt%2Freplicas%2F1&part=20250728_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.6.10636.altinitytest (altinity build)) '. (RECEIVED_ERROR_FROM_REMOTE_IO_SERVER), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.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 const&, int&&, String const&, unsigned long&&, String const&) @ 0x000000000feda8d9 4. /build/src/IO/HTTPCommon.cpp:104: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x000000000feda6e2 5. /build/src/IO/HTTPCommon.cpp:93: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x000000000feda537 6. /build/src/IO/ReadWriteBufferFromHTTP.cpp:277: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x000000001184a4c4 7. /build/src/IO/ReadWriteBufferFromHTTP.cpp:285: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x000000001184a615 8. /build/src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x000000001184ae59 9. /build/src/IO/ReadWriteBufferFromHTTP.cpp:472: void std::__function::__policy_invoker::__call_impl[abi:se190107]>(std::__function::__policy_storage const*) @ 0x000000001184cedd 10. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001184858b 11. /build/src/IO/ReadWriteBufferFromHTTP.cpp:465: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x000000001184bf0b 12. /build/src/IO/ReadBuffer.h:60: DB::ReadBuffer::next() @ 0x000000000a148c7b 13. /build/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) @ 0x0000000011849fb2 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]>&)>&, 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&) @ 0x0000000011841980 15. /build/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) @ 0x000000001621208e 16. /build/src/Storages/StorageReplicatedMergeTree.cpp:5228: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl[abi:se190107] const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000015f9a5fe 17. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000015ed8bfd 18. /build/src/Storages/StorageReplicatedMergeTree.cpp:2514: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x0000000015ec9aab 19. /build/src/Storages/StorageReplicatedMergeTree.cpp:2349: DB::StorageReplicatedMergeTree::executeLogEntry(DB::ReplicatedMergeTreeLogEntry&) @ 0x0000000015eba91b 20. /build/src/Storages/StorageReplicatedMergeTree.cpp:3876: bool std::__function::__policy_invoker&)>::__call_impl[abi:se190107])::$_1, bool (std::shared_ptr&)>>(std::__function::__policy_storage const*, std::shared_ptr&) @ 0x0000000015f9837e 21. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000165d6fc3 22. /build/src/Storages/StorageReplicatedMergeTree.cpp:3872: DB::StorageReplicatedMergeTree::processQueueEntry(std::shared_ptr) @ 0x0000000015efc18a 23. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001624c1b2 24. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000162f9c70 25. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x00000000162fa55a 26. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc6653 27. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000000fccc4c3 28. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc3d92 29. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fcca080 30. ? @ 0x00007fbc6213eac3 31. ? @ 0x00007fbc621d0850 (version 25.3.6.10636.altinitytest (altinity build)) 2025.07.28 11:54:27.894900 [ 4581 ] {e4af7004-450c-4998-9f6b-9087d3606da9} 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.6.10636.altinitytest (altinity build)) (from [::1]:48136) (comment: 02124_insert_deduplication_token_materialized_views.sql) (query 7, line 12) (in query: CREATE TABLE test (`test` String, `A` Int64, `B` Int64) ENGINE = ReplicatedMergeTree('/clickhouse/tables/{database}/test_02124/{table}', '1') ORDER BY tuple() SETTINGS index_granularity = 13430, min_bytes_for_wide_part = 1073741824, ratio_of_defaults_for_sparse_serialization = 0.9426461458206177, replace_long_file_name_to_hash = false, max_file_name_length = 65, min_bytes_for_full_part_storage = 536870912, compact_parts_max_bytes_to_buffer = 92716882, compact_parts_max_granules_to_buffer = 1, compact_parts_merge_max_bytes_to_prefetch_part = 12221558, merge_max_block_size = 17640, old_parts_lifetime = 314., 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 = 1, index_granularity_bytes = 14529609, 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 = false, marks_compress_block_size = 49581, primary_key_compress_block_size = 47884, 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. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000000a074fcb 4. /build/src/Databases/DatabaseReplicated.cpp:959: DB::DatabaseReplicated::checkTableEngine(DB::ASTCreateQuery const&, DB::ASTStorage&, std::shared_ptr) const @ 0x0000000013d9cf56 5. /build/src/Databases/DatabaseReplicated.cpp:1083: DB::DatabaseReplicated::checkQueryValid(std::shared_ptr const&, std::shared_ptr) const @ 0x0000000013d9ebb5 6. /build/src/Databases/DatabaseReplicated.cpp:1130: DB::DatabaseReplicated::tryEnqueueReplicatedDDL(std::shared_ptr const&, std::shared_ptr, DB::QueryFlags) @ 0x0000000013d9f10b 7. /build/src/Interpreters/InterpreterCreateQuery.cpp:1723: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000148f96f8 8. /build/src/Interpreters/InterpreterCreateQuery.cpp:2352: DB::InterpreterCreateQuery::execute() @ 0x0000000014905a41 9. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88dc9 10. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 11. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 12. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 13. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 14. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 16. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 17. ? @ 0x00007fbc6213eac3 18. ? @ 0x00007fbc621d0850 2025.07.28 11:54:27.903809 [ 4581 ] {} 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. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000000a074fcb 4. /build/src/Databases/DatabaseReplicated.cpp:959: DB::DatabaseReplicated::checkTableEngine(DB::ASTCreateQuery const&, DB::ASTStorage&, std::shared_ptr) const @ 0x0000000013d9cf56 5. /build/src/Databases/DatabaseReplicated.cpp:1083: DB::DatabaseReplicated::checkQueryValid(std::shared_ptr const&, std::shared_ptr) const @ 0x0000000013d9ebb5 6. /build/src/Databases/DatabaseReplicated.cpp:1130: DB::DatabaseReplicated::tryEnqueueReplicatedDDL(std::shared_ptr const&, std::shared_ptr, DB::QueryFlags) @ 0x0000000013d9f10b 7. /build/src/Interpreters/InterpreterCreateQuery.cpp:1723: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000148f96f8 8. /build/src/Interpreters/InterpreterCreateQuery.cpp:2352: DB::InterpreterCreateQuery::execute() @ 0x0000000014905a41 9. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88dc9 10. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 11. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 12. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 13. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 14. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 16. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 17. ? @ 0x00007fbc6213eac3 18. ? @ 0x00007fbc621d0850 2025.07.28 11:54:28.661053 [ 3971 ] {} test_13.rmt2 (7f9b740d-015c-470e-8cc6-8ba33be0dc63): auto DB::StorageReplicatedMergeTree::processQueueEntry(ReplicatedMergeTreeQueue::SelectedEntryPtr)::(anonymous class)::operator()(LogEntryPtr &) const: Code: 86. DB::HTTPException: Received error from remote server http://146b4357c08d:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Ftest%2F01165%2Ftest_13%2Frmt%2Freplicas%2F1&part=20250728_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.6.10636.altinitytest (altinity build)) '. (RECEIVED_ERROR_FROM_REMOTE_IO_SERVER), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.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 const&, int&&, String const&, unsigned long&&, String const&) @ 0x000000000feda8d9 4. /build/src/IO/HTTPCommon.cpp:104: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x000000000feda6e2 5. /build/src/IO/HTTPCommon.cpp:93: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x000000000feda537 6. /build/src/IO/ReadWriteBufferFromHTTP.cpp:277: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x000000001184a4c4 7. /build/src/IO/ReadWriteBufferFromHTTP.cpp:285: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x000000001184a615 8. /build/src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x000000001184ae59 9. /build/src/IO/ReadWriteBufferFromHTTP.cpp:472: void std::__function::__policy_invoker::__call_impl[abi:se190107]>(std::__function::__policy_storage const*) @ 0x000000001184cedd 10. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001184858b 11. /build/src/IO/ReadWriteBufferFromHTTP.cpp:465: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x000000001184bf0b 12. /build/src/IO/ReadBuffer.h:60: DB::ReadBuffer::next() @ 0x000000000a148c7b 13. /build/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) @ 0x0000000011849fb2 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]>&)>&, 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&) @ 0x0000000011841980 15. /build/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) @ 0x000000001621208e 16. /build/src/Storages/StorageReplicatedMergeTree.cpp:5228: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl[abi:se190107] const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000015f9a5fe 17. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000015ed8bfd 18. /build/src/Storages/StorageReplicatedMergeTree.cpp:2514: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x0000000015ec9aab 19. /build/src/Storages/StorageReplicatedMergeTree.cpp:2349: DB::StorageReplicatedMergeTree::executeLogEntry(DB::ReplicatedMergeTreeLogEntry&) @ 0x0000000015eba91b 20. /build/src/Storages/StorageReplicatedMergeTree.cpp:3876: bool std::__function::__policy_invoker&)>::__call_impl[abi:se190107])::$_1, bool (std::shared_ptr&)>>(std::__function::__policy_storage const*, std::shared_ptr&) @ 0x0000000015f9837e 21. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000165d6fc3 22. /build/src/Storages/StorageReplicatedMergeTree.cpp:3872: DB::StorageReplicatedMergeTree::processQueueEntry(std::shared_ptr) @ 0x0000000015efc18a 23. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001624c1b2 24. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000162f9c70 25. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x00000000162fa55a 26. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc6653 27. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000000fccc4c3 28. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc3d92 29. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fcca080 30. ? @ 0x00007fbc6213eac3 31. ? @ 0x00007fbc621d0850 (version 25.3.6.10636.altinitytest (altinity build)) 2025.07.28 11:54:28.683147 [ 17208 ] {68cf8f7e-a815-4d28-a238-b81ce6a2f6fc} executeQuery: Code: 153. DB::Exception: Division by zero: while executing 'FUNCTION modulo(1_UInt8 :: 1, modulo(plus(__table1.number, 500_UInt16), 1000_UInt16) :: 2) -> modulo(1_UInt8, modulo(plus(__table1.number, 500_UInt16), 1000_UInt16)) UInt16 : 3'. (ILLEGAL_DIVISION) (version 25.3.6.10636.altinitytest (altinity build)) (from [::1]:48062) (comment: 00093_union_race_conditions_4.sh) (query 1, line 1) (in query: SELECT 1 % ((number + 500) % 1000) FROM numbers_mt(1000);), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000000a074fcb 4. /build/src/Functions/DivisionUtils.h:26: void DB::impl_::BinaryOperation, unsigned short>::process<(DB::impl_::OpCase)1>(char8_t const*, unsigned short const*, unsigned short*, unsigned long, DB::PODArray, 63ul, 64ul> const*) @ 0x000000000d184621 5. /build/src/Functions/FunctionBinaryArithmetic.h:2338: COW::immutable_ptr DB::FunctionBinaryArithmetic::executeNumeric, DB::DataTypeNumber>(std::vector> const&, DB::DataTypeNumber const&, DB::DataTypeNumber const&, DB::PODArray, 63ul, 64ul> const*) const @ 0x000000000d3a6416 6. /build/src/Functions/FunctionBinaryArithmetic.h:2508: 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&&) @ 0x000000000d3a4a68 7. /build/src/Functions/FunctionBinaryArithmetic.h:846: 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&&) @ 0x000000000d3a3ec7 8. /build/src/Functions/FunctionBinaryArithmetic.h:844: DB::FunctionBinaryArithmetic::executeImpl2(std::vector> const&, std::shared_ptr const&, unsigned long, DB::PODArray, 63ul, 64ul> const*) const @ 0x000000000d3a03c5 9. /build/src/Functions/FunctionBinaryArithmetic.h:2410: DB::FunctionBinaryArithmetic::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000d39e94c 10. /build/src/Functions/FunctionBinaryArithmetic.h:2645: DB::FunctionBinaryArithmeticWithConstants::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000d39dbd4 11. /build/src/Functions/IFunctionAdaptors.cpp:10: DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000012d995fa 12. /build/src/Functions/IFunction.cpp:353: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d93b52 13. /build/src/Functions/IFunction.cpp:420: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d95059 14. /build/src/Functions/IFunction.cpp:498: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d95c72 15. /build/src/Interpreters/ExpressionActions.cpp:636: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x00000000145176f3 16. /build/src/Processors/Transforms/ExpressionTransform.cpp:25: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x0000000016c0b34c 17. /build/src/Processors/ISimpleTransform.h:33: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000011a9a453 18. /build/src/Processors/ISimpleTransform.cpp:89: DB::ISimpleTransform::work() @ 0x000000001699fca0 19. /build/src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x00000000169bd00f 20. /build/src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x00000000169b2105 21. /build/src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeSingleThread(unsigned long) @ 0x00000000169b23be 22. /build/src/Processors/Executors/PipelineExecutor.cpp:454: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x00000000169b0be7 23. /build/src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x00000000169b03f4 24. /build/src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:se190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169bfeab 25. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc3d92 26. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fcca080 27. ? @ 0x00007fbc6213eac3 28. ? @ 0x00007fbc621d0850 2025.07.28 11:54:28.714992 [ 17208 ] {} TCPHandler: Code: 153. DB::Exception: Division by zero: while executing 'FUNCTION modulo(1_UInt8 :: 1, modulo(plus(__table1.number, 500_UInt16), 1000_UInt16) :: 2) -> modulo(1_UInt8, modulo(plus(__table1.number, 500_UInt16), 1000_UInt16)) UInt16 : 3'. (ILLEGAL_DIVISION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000000a074fcb 4. /build/src/Functions/DivisionUtils.h:26: void DB::impl_::BinaryOperation, unsigned short>::process<(DB::impl_::OpCase)1>(char8_t const*, unsigned short const*, unsigned short*, unsigned long, DB::PODArray, 63ul, 64ul> const*) @ 0x000000000d184621 5. /build/src/Functions/FunctionBinaryArithmetic.h:2338: COW::immutable_ptr DB::FunctionBinaryArithmetic::executeNumeric, DB::DataTypeNumber>(std::vector> const&, DB::DataTypeNumber const&, DB::DataTypeNumber const&, DB::PODArray, 63ul, 64ul> const*) const @ 0x000000000d3a6416 6. /build/src/Functions/FunctionBinaryArithmetic.h:2508: 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&&) @ 0x000000000d3a4a68 7. /build/src/Functions/FunctionBinaryArithmetic.h:846: 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&&) @ 0x000000000d3a3ec7 8. /build/src/Functions/FunctionBinaryArithmetic.h:844: DB::FunctionBinaryArithmetic::executeImpl2(std::vector> const&, std::shared_ptr const&, unsigned long, DB::PODArray, 63ul, 64ul> const*) const @ 0x000000000d3a03c5 9. /build/src/Functions/FunctionBinaryArithmetic.h:2410: DB::FunctionBinaryArithmetic::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000d39e94c 10. /build/src/Functions/FunctionBinaryArithmetic.h:2645: DB::FunctionBinaryArithmeticWithConstants::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000d39dbd4 11. /build/src/Functions/IFunctionAdaptors.cpp:10: DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000012d995fa 12. /build/src/Functions/IFunction.cpp:353: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d93b52 13. /build/src/Functions/IFunction.cpp:420: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d95059 14. /build/src/Functions/IFunction.cpp:498: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d95c72 15. /build/src/Interpreters/ExpressionActions.cpp:636: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x00000000145176f3 16. /build/src/Processors/Transforms/ExpressionTransform.cpp:25: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x0000000016c0b34c 17. /build/src/Processors/ISimpleTransform.h:33: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000011a9a453 18. /build/src/Processors/ISimpleTransform.cpp:89: DB::ISimpleTransform::work() @ 0x000000001699fca0 19. /build/src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x00000000169bd00f 20. /build/src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x00000000169b2105 21. /build/src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeSingleThread(unsigned long) @ 0x00000000169b23be 22. /build/src/Processors/Executors/PipelineExecutor.cpp:454: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x00000000169b0be7 23. /build/src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x00000000169b03f4 24. /build/src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:se190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169bfeab 25. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc3d92 26. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fcca080 27. ? @ 0x00007fbc6213eac3 28. ? @ 0x00007fbc621d0850 Job's origin stack trace: 0. /build/src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000000fc33b84 1. /build/src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000000fcc2ea7 2. /build/src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fcc535c 3. /build/src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000000fcc584d 4. /build/src/Common/ThreadPool.h:279: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x00000000169bf193 5. /build/src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x00000000169bf518 6. /build/src/Server/TCPHandler.cpp:1237: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x00000000168f1525 7. /build/src/Server/TCPHandler.cpp:678: DB::TCPHandler::runImpl() @ 0x00000000168e68e5 8. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 9. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 10. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 11. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 12. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 13. ? @ 0x00007fbc6213eac3 14. ? @ 0x00007fbc621d0850 2025.07.28 11:54:29.369576 [ 3972 ] {} test_13.rmt2 (7f9b740d-015c-470e-8cc6-8ba33be0dc63): auto DB::StorageReplicatedMergeTree::processQueueEntry(ReplicatedMergeTreeQueue::SelectedEntryPtr)::(anonymous class)::operator()(LogEntryPtr &) const: Code: 86. DB::HTTPException: Received error from remote server http://146b4357c08d:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Ftest%2F01165%2Ftest_13%2Frmt%2Freplicas%2F1&part=20250728_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.6.10636.altinitytest (altinity build)) '. (RECEIVED_ERROR_FROM_REMOTE_IO_SERVER), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.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 const&, int&&, String const&, unsigned long&&, String const&) @ 0x000000000feda8d9 4. /build/src/IO/HTTPCommon.cpp:104: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x000000000feda6e2 5. /build/src/IO/HTTPCommon.cpp:93: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x000000000feda537 6. /build/src/IO/ReadWriteBufferFromHTTP.cpp:277: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x000000001184a4c4 7. /build/src/IO/ReadWriteBufferFromHTTP.cpp:285: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x000000001184a615 8. /build/src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x000000001184ae59 9. /build/src/IO/ReadWriteBufferFromHTTP.cpp:472: void std::__function::__policy_invoker::__call_impl[abi:se190107]>(std::__function::__policy_storage const*) @ 0x000000001184cedd 10. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001184858b 11. /build/src/IO/ReadWriteBufferFromHTTP.cpp:465: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x000000001184bf0b 12. /build/src/IO/ReadBuffer.h:60: DB::ReadBuffer::next() @ 0x000000000a148c7b 13. /build/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) @ 0x0000000011849fb2 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]>&)>&, 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&) @ 0x0000000011841980 15. /build/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) @ 0x000000001621208e 16. /build/src/Storages/StorageReplicatedMergeTree.cpp:5228: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl[abi:se190107] const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000015f9a5fe 17. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000015ed8bfd 18. /build/src/Storages/StorageReplicatedMergeTree.cpp:2514: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x0000000015ec9aab 19. /build/src/Storages/StorageReplicatedMergeTree.cpp:2349: DB::StorageReplicatedMergeTree::executeLogEntry(DB::ReplicatedMergeTreeLogEntry&) @ 0x0000000015eba91b 20. /build/src/Storages/StorageReplicatedMergeTree.cpp:3876: bool std::__function::__policy_invoker&)>::__call_impl[abi:se190107])::$_1, bool (std::shared_ptr&)>>(std::__function::__policy_storage const*, std::shared_ptr&) @ 0x0000000015f9837e 21. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000165d6fc3 22. /build/src/Storages/StorageReplicatedMergeTree.cpp:3872: DB::StorageReplicatedMergeTree::processQueueEntry(std::shared_ptr) @ 0x0000000015efc18a 23. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001624c1b2 24. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000162f9c70 25. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x00000000162fa55a 26. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc6653 27. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000000fccc4c3 28. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc3d92 29. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fcca080 30. ? @ 0x00007fbc6213eac3 31. ? @ 0x00007fbc621d0850 (version 25.3.6.10636.altinitytest (altinity build)) 2025.07.28 11:54:29.380984 [ 17210 ] {} 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. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception>&, String>(int, FormatStringHelperImpl>&>::type, std::type_identity::type>, std::basic_string_view>&, String&&) @ 0x000000001385a5eb 4. /build/src/Access/SettingsConstraints.cpp:376: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000013859b18 5. /build/src/Access/SettingsConstraints.cpp:300: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000013858faf 6. /build/src/Access/SettingsConstraints.cpp:209: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000013859223 7. /build/src/Interpreters/Context.cpp:2690: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000014436134 8. /build/src/Interpreters/Context.cpp:2729: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x000000001443662b 9. /build/src/Server/HTTPHandler.cpp:457: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000001686d165 10. /build/src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x0000000016870807 11. /build/src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x0000000016907e99 12. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 13. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 14. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 15. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 16. ? @ 0x00007fbc6213eac3 17. ? @ 0x00007fbc621d0850 (version 25.3.6.10636.altinitytest (altinity build)) 2025.07.28 11:54:29.735553 [ 3974 ] {} test_13.rmt2 (7f9b740d-015c-470e-8cc6-8ba33be0dc63): auto DB::StorageReplicatedMergeTree::processQueueEntry(ReplicatedMergeTreeQueue::SelectedEntryPtr)::(anonymous class)::operator()(LogEntryPtr &) const: Code: 86. DB::HTTPException: Received error from remote server http://146b4357c08d:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Ftest%2F01165%2Ftest_13%2Frmt%2Freplicas%2F1&part=20250728_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.6.10636.altinitytest (altinity build)) '. (RECEIVED_ERROR_FROM_REMOTE_IO_SERVER), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.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 const&, int&&, String const&, unsigned long&&, String const&) @ 0x000000000feda8d9 4. /build/src/IO/HTTPCommon.cpp:104: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x000000000feda6e2 5. /build/src/IO/HTTPCommon.cpp:93: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x000000000feda537 6. /build/src/IO/ReadWriteBufferFromHTTP.cpp:277: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x000000001184a4c4 7. /build/src/IO/ReadWriteBufferFromHTTP.cpp:285: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x000000001184a615 8. /build/src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x000000001184ae59 9. /build/src/IO/ReadWriteBufferFromHTTP.cpp:472: void std::__function::__policy_invoker::__call_impl[abi:se190107]>(std::__function::__policy_storage const*) @ 0x000000001184cedd 10. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001184858b 11. /build/src/IO/ReadWriteBufferFromHTTP.cpp:465: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x000000001184bf0b 12. /build/src/IO/ReadBuffer.h:60: DB::ReadBuffer::next() @ 0x000000000a148c7b 13. /build/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) @ 0x0000000011849fb2 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]>&)>&, 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&) @ 0x0000000011841980 15. /build/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) @ 0x000000001621208e 16. /build/src/Storages/StorageReplicatedMergeTree.cpp:5228: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl[abi:se190107] const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000015f9a5fe 17. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000015ed8bfd 18. /build/src/Storages/StorageReplicatedMergeTree.cpp:2514: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x0000000015ec9aab 19. /build/src/Storages/StorageReplicatedMergeTree.cpp:2349: DB::StorageReplicatedMergeTree::executeLogEntry(DB::ReplicatedMergeTreeLogEntry&) @ 0x0000000015eba91b 20. /build/src/Storages/StorageReplicatedMergeTree.cpp:3876: bool std::__function::__policy_invoker&)>::__call_impl[abi:se190107])::$_1, bool (std::shared_ptr&)>>(std::__function::__policy_storage const*, std::shared_ptr&) @ 0x0000000015f9837e 21. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000165d6fc3 22. /build/src/Storages/StorageReplicatedMergeTree.cpp:3872: DB::StorageReplicatedMergeTree::processQueueEntry(std::shared_ptr) @ 0x0000000015efc18a 23. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001624c1b2 24. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000162f9c70 25. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x00000000162fa55a 26. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc6653 27. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000000fccc4c3 28. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc3d92 29. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fcca080 30. ? @ 0x00007fbc6213eac3 31. ? @ 0x00007fbc621d0850 (version 25.3.6.10636.altinitytest (altinity build)) 2025.07.28 11:54:29.816560 [ 4963 ] {4c90e225-63b8-4270-9b58-5d44b9286a3b} executeQuery: Code: 57. DB::Exception: Table test_13.test already exists. (TABLE_ALREADY_EXISTS) (version 25.3.6.10636.altinitytest (altinity build)) (from [::1]:48194) (comment: 02950_parallel_replicas_used_count.sql) (query 2, line 3) (in query: CREATE TABLE test (`k` UInt64, `v` String) ENGINE = MergeTree ORDER BY k SETTINGS index_granularity = 1, min_bytes_for_wide_part = 617806461, 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 = 267464029, compact_parts_max_bytes_to_buffer = 432883572, compact_parts_max_granules_to_buffer = 135, compact_parts_merge_max_bytes_to_prefetch_part = 21670207, merge_max_block_size = 18127, old_parts_lifetime = 480., prefer_fetch_merged_part_size_threshold = 1, vertical_merge_algorithm_min_rows_to_activate = 372284, vertical_merge_algorithm_min_columns_to_activate = 1, min_merge_bytes_to_use_direct_io = 9116627935, index_granularity_bytes = 29005540, use_const_adaptive_granularity = false, enable_index_granularity_compression = false, concurrent_part_removal_threshold = 100, 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 = 30505, primary_key_compress_block_size = 24798, 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. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000a06a8eb 4. /build/src/Interpreters/InterpreterCreateQuery.cpp:1824: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x0000000014901d53 5. /build/src/Interpreters/InterpreterCreateQuery.cpp:1743: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000148f9aa9 6. /build/src/Interpreters/InterpreterCreateQuery.cpp:2352: DB::InterpreterCreateQuery::execute() @ 0x0000000014905a41 7. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88dc9 8. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 9. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 10. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 11. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 12. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 13. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 14. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 15. ? @ 0x00007fbc6213eac3 16. ? @ 0x00007fbc621d0850 2025.07.28 11:54:29.838001 [ 4963 ] {} TCPHandler: Code: 57. DB::Exception: Table test_13.test already exists. (TABLE_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000a06a8eb 4. /build/src/Interpreters/InterpreterCreateQuery.cpp:1824: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x0000000014901d53 5. /build/src/Interpreters/InterpreterCreateQuery.cpp:1743: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000148f9aa9 6. /build/src/Interpreters/InterpreterCreateQuery.cpp:2352: DB::InterpreterCreateQuery::execute() @ 0x0000000014905a41 7. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88dc9 8. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 9. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 10. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 11. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 12. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 13. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 14. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 15. ? @ 0x00007fbc6213eac3 16. ? @ 0x00007fbc621d0850 2025.07.28 11:54:30.467735 [ 17611 ] {} 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. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception>&, String>(int, FormatStringHelperImpl>&>::type, std::type_identity::type>, std::basic_string_view>&, String&&) @ 0x000000001385a5eb 4. /build/src/Access/SettingsConstraints.cpp:376: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000013859b18 5. /build/src/Access/SettingsConstraints.cpp:300: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000013858faf 6. /build/src/Access/SettingsConstraints.cpp:209: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000013859223 7. /build/src/Interpreters/Context.cpp:2690: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000014436134 8. /build/src/Interpreters/Context.cpp:2729: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x000000001443662b 9. /build/src/Server/HTTPHandler.cpp:457: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000001686d165 10. /build/src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x0000000016870807 11. /build/src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x0000000016907e99 12. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 13. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 14. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 15. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 16. ? @ 0x00007fbc6213eac3 17. ? @ 0x00007fbc621d0850 (version 25.3.6.10636.altinitytest (altinity build)) 2025.07.28 11:54:30.597854 [ 17232 ] {daa66215-55a0-4de1-b19b-defbea7c9906} executeQuery: Code: 36. DB::Exception: Parameter for aggregate function groupArrayMovingSum should be positive integer. (BAD_ARGUMENTS) (version 25.3.6.10636.altinitytest (altinity build)) (from [::1]:48158) (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. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000a9b78ab 4. /build/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*) @ 0x000000001151f77b 5. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000131e00dd 6. /build/src/AggregateFunctions/AggregateFunctionFactory.cpp:130: DB::AggregateFunctionFactory::get(String const&, DB::NullsAction, std::vector, std::allocator>> const&, DB::Array const&, DB::AggregateFunctionProperties&) const @ 0x00000000131df0ca 7. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3368: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000014032fed 8. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3838: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000014019a9e 9. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3980: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000014018e31 10. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:4304: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000014042fa7 11. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5605: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000014013749 12. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000140127f9 13. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000014011fce 14. /build/src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000001406ce8a 15. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000014973b42 16. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000001497268d 17. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000014974d24 18. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001492924b 19. /build/src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88641 20. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 21. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 22. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 23. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 24. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 25. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 26. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 27. ? @ 0x00007fbc6213eac3 28. ? @ 0x00007fbc621d0850 2025.07.28 11:54:30.607708 [ 17232 ] {} 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. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000a9b78ab 4. /build/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*) @ 0x000000001151f77b 5. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000131e00dd 6. /build/src/AggregateFunctions/AggregateFunctionFactory.cpp:130: DB::AggregateFunctionFactory::get(String const&, DB::NullsAction, std::vector, std::allocator>> const&, DB::Array const&, DB::AggregateFunctionProperties&) const @ 0x00000000131df0ca 7. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3368: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000014032fed 8. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3838: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000014019a9e 9. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3980: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000014018e31 10. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:4304: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000014042fa7 11. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5605: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000014013749 12. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000140127f9 13. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000014011fce 14. /build/src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000001406ce8a 15. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000014973b42 16. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000001497268d 17. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000014974d24 18. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001492924b 19. /build/src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88641 20. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 21. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 22. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 23. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 24. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 25. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 26. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 27. ? @ 0x00007fbc6213eac3 28. ? @ 0x00007fbc621d0850 2025.07.28 11:54:30.683313 [ 3960 ] {} test_13.rmt2 (7f9b740d-015c-470e-8cc6-8ba33be0dc63): auto DB::StorageReplicatedMergeTree::processQueueEntry(ReplicatedMergeTreeQueue::SelectedEntryPtr)::(anonymous class)::operator()(LogEntryPtr &) const: Code: 86. DB::HTTPException: Received error from remote server http://146b4357c08d:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Ftest%2F01165%2Ftest_13%2Frmt%2Freplicas%2F1&part=20250728_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.6.10636.altinitytest (altinity build)) '. (RECEIVED_ERROR_FROM_REMOTE_IO_SERVER), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.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 const&, int&&, String const&, unsigned long&&, String const&) @ 0x000000000feda8d9 4. /build/src/IO/HTTPCommon.cpp:104: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x000000000feda6e2 5. /build/src/IO/HTTPCommon.cpp:93: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x000000000feda537 6. /build/src/IO/ReadWriteBufferFromHTTP.cpp:277: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x000000001184a4c4 7. /build/src/IO/ReadWriteBufferFromHTTP.cpp:285: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x000000001184a615 8. /build/src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x000000001184ae59 9. /build/src/IO/ReadWriteBufferFromHTTP.cpp:472: void std::__function::__policy_invoker::__call_impl[abi:se190107]>(std::__function::__policy_storage const*) @ 0x000000001184cedd 10. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001184858b 11. /build/src/IO/ReadWriteBufferFromHTTP.cpp:465: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x000000001184bf0b 12. /build/src/IO/ReadBuffer.h:60: DB::ReadBuffer::next() @ 0x000000000a148c7b 13. /build/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) @ 0x0000000011849fb2 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]>&)>&, 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&) @ 0x0000000011841980 15. /build/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) @ 0x000000001621208e 16. /build/src/Storages/StorageReplicatedMergeTree.cpp:5228: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl[abi:se190107] const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000015f9a5fe 17. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000015ed8bfd 18. /build/src/Storages/StorageReplicatedMergeTree.cpp:2514: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x0000000015ec9aab 19. /build/src/Storages/StorageReplicatedMergeTree.cpp:2349: DB::StorageReplicatedMergeTree::executeLogEntry(DB::ReplicatedMergeTreeLogEntry&) @ 0x0000000015eba91b 20. /build/src/Storages/StorageReplicatedMergeTree.cpp:3876: bool std::__function::__policy_invoker&)>::__call_impl[abi:se190107])::$_1, bool (std::shared_ptr&)>>(std::__function::__policy_storage const*, std::shared_ptr&) @ 0x0000000015f9837e 21. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000165d6fc3 22. /build/src/Storages/StorageReplicatedMergeTree.cpp:3872: DB::StorageReplicatedMergeTree::processQueueEntry(std::shared_ptr) @ 0x0000000015efc18a 23. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001624c1b2 24. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000162f9c70 25. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x00000000162fa55a 26. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc6653 27. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000000fccc4c3 28. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc3d92 29. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fcca080 30. ? @ 0x00007fbc6213eac3 31. ? @ 0x00007fbc621d0850 (version 25.3.6.10636.altinitytest (altinity build)) 2025.07.28 11:54:30.735747 [ 17232 ] {1613c4e0-eb2d-4d60-a791-101b7e7390a8} executeQuery: Code: 36. DB::Exception: Parameter for aggregate function groupArrayMovingSum should be positive integer. (BAD_ARGUMENTS) (version 25.3.6.10636.altinitytest (altinity build)) (from [::1]:48158) (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. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000a9b78ab 4. /build/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*) @ 0x000000001151f710 5. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000131e00dd 6. /build/src/AggregateFunctions/AggregateFunctionFactory.cpp:130: DB::AggregateFunctionFactory::get(String const&, DB::NullsAction, std::vector, std::allocator>> const&, DB::Array const&, DB::AggregateFunctionProperties&) const @ 0x00000000131df0ca 7. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3368: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000014032fed 8. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3838: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000014019a9e 9. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3980: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000014018e31 10. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:4304: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000014042fa7 11. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5605: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000014013749 12. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000140127f9 13. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000014011fce 14. /build/src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000001406ce8a 15. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000014973b42 16. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000001497268d 17. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000014974d24 18. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001492924b 19. /build/src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88641 20. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 21. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 22. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 23. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 24. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 25. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 26. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 27. ? @ 0x00007fbc6213eac3 28. ? @ 0x00007fbc621d0850 2025.07.28 11:54:30.745481 [ 17232 ] {} 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. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000a9b78ab 4. /build/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*) @ 0x000000001151f710 5. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000131e00dd 6. /build/src/AggregateFunctions/AggregateFunctionFactory.cpp:130: DB::AggregateFunctionFactory::get(String const&, DB::NullsAction, std::vector, std::allocator>> const&, DB::Array const&, DB::AggregateFunctionProperties&) const @ 0x00000000131df0ca 7. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3368: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000014032fed 8. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3838: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000014019a9e 9. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3980: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000014018e31 10. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:4304: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000014042fa7 11. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5605: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000014013749 12. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000140127f9 13. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000014011fce 14. /build/src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000001406ce8a 15. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000014973b42 16. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000001497268d 17. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000014974d24 18. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001492924b 19. /build/src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88641 20. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 21. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 22. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 23. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 24. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 25. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 26. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 27. ? @ 0x00007fbc6213eac3 28. ? @ 0x00007fbc621d0850 2025.07.28 11:54:30.864368 [ 17232 ] {080d6690-9b9f-4f3b-8b72-fec06230c2ab} executeQuery: Code: 36. DB::Exception: Parameter for aggregate function groupArrayMovingSum should be positive integer. (BAD_ARGUMENTS) (version 25.3.6.10636.altinitytest (altinity build)) (from [::1]:48158) (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. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000a9b78ab 4. /build/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*) @ 0x000000001151f710 5. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000131e00dd 6. /build/src/AggregateFunctions/AggregateFunctionFactory.cpp:130: DB::AggregateFunctionFactory::get(String const&, DB::NullsAction, std::vector, std::allocator>> const&, DB::Array const&, DB::AggregateFunctionProperties&) const @ 0x00000000131df0ca 7. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3368: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000014032fed 8. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3838: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000014019a9e 9. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3980: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000014018e31 10. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:4304: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000014042fa7 11. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5605: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000014013749 12. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000140127f9 13. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000014011fce 14. /build/src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000001406ce8a 15. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000014973b42 16. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000001497268d 17. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000014974d24 18. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001492924b 19. /build/src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88641 20. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 21. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 22. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 23. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 24. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 25. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 26. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 27. ? @ 0x00007fbc6213eac3 28. ? @ 0x00007fbc621d0850 2025.07.28 11:54:30.886673 [ 17232 ] {} 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. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000a9b78ab 4. /build/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*) @ 0x000000001151f710 5. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000131e00dd 6. /build/src/AggregateFunctions/AggregateFunctionFactory.cpp:130: DB::AggregateFunctionFactory::get(String const&, DB::NullsAction, std::vector, std::allocator>> const&, DB::Array const&, DB::AggregateFunctionProperties&) const @ 0x00000000131df0ca 7. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3368: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000014032fed 8. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3838: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000014019a9e 9. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3980: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000014018e31 10. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:4304: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000014042fa7 11. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5605: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000014013749 12. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000140127f9 13. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000014011fce 14. /build/src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000001406ce8a 15. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000014973b42 16. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000001497268d 17. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000014974d24 18. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001492924b 19. /build/src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88641 20. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 21. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 22. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 23. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 24. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 25. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 26. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 27. ? @ 0x00007fbc6213eac3 28. ? @ 0x00007fbc621d0850 2025.07.28 11:54:30.979781 [ 17232 ] {2a26aa89-3e82-4ec9-b5e9-e970edc2e200} executeQuery: Code: 36. DB::Exception: Parameter for aggregate function groupArrayMovingSum should be positive integer. (BAD_ARGUMENTS) (version 25.3.6.10636.altinitytest (altinity build)) (from [::1]:48158) (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. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000a9b78ab 4. /build/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*) @ 0x000000001151f710 5. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000131e00dd 6. /build/src/AggregateFunctions/AggregateFunctionFactory.cpp:130: DB::AggregateFunctionFactory::get(String const&, DB::NullsAction, std::vector, std::allocator>> const&, DB::Array const&, DB::AggregateFunctionProperties&) const @ 0x00000000131df0ca 7. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3368: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000014032fed 8. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3838: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000014019a9e 9. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3980: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000014018e31 10. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:4304: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000014042fa7 11. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5605: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000014013749 12. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000140127f9 13. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000014011fce 14. /build/src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000001406ce8a 15. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000014973b42 16. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000001497268d 17. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000014974d24 18. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001492924b 19. /build/src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88641 20. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 21. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 22. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 23. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 24. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 25. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 26. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 27. ? @ 0x00007fbc6213eac3 28. ? @ 0x00007fbc621d0850 2025.07.28 11:54:30.988917 [ 17232 ] {} 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. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000a9b78ab 4. /build/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*) @ 0x000000001151f710 5. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000131e00dd 6. /build/src/AggregateFunctions/AggregateFunctionFactory.cpp:130: DB::AggregateFunctionFactory::get(String const&, DB::NullsAction, std::vector, std::allocator>> const&, DB::Array const&, DB::AggregateFunctionProperties&) const @ 0x00000000131df0ca 7. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3368: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000014032fed 8. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3838: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000014019a9e 9. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3980: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000014018e31 10. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:4304: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000014042fa7 11. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5605: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000014013749 12. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000140127f9 13. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000014011fce 14. /build/src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000001406ce8a 15. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000014973b42 16. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000001497268d 17. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000014974d24 18. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001492924b 19. /build/src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88641 20. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 21. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 22. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 23. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 24. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 25. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 26. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 27. ? @ 0x00007fbc6213eac3 28. ? @ 0x00007fbc621d0850 2025.07.28 11:54:31.677346 [ 3971 ] {} test_13.rmt2 (7f9b740d-015c-470e-8cc6-8ba33be0dc63): auto DB::StorageReplicatedMergeTree::processQueueEntry(ReplicatedMergeTreeQueue::SelectedEntryPtr)::(anonymous class)::operator()(LogEntryPtr &) const: Code: 86. DB::HTTPException: Received error from remote server http://146b4357c08d:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Ftest%2F01165%2Ftest_13%2Frmt%2Freplicas%2F1&part=20250728_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.6.10636.altinitytest (altinity build)) '. (RECEIVED_ERROR_FROM_REMOTE_IO_SERVER), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.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 const&, int&&, String const&, unsigned long&&, String const&) @ 0x000000000feda8d9 4. /build/src/IO/HTTPCommon.cpp:104: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x000000000feda6e2 5. /build/src/IO/HTTPCommon.cpp:93: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x000000000feda537 6. /build/src/IO/ReadWriteBufferFromHTTP.cpp:277: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x000000001184a4c4 7. /build/src/IO/ReadWriteBufferFromHTTP.cpp:285: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x000000001184a615 8. /build/src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x000000001184ae59 9. /build/src/IO/ReadWriteBufferFromHTTP.cpp:472: void std::__function::__policy_invoker::__call_impl[abi:se190107]>(std::__function::__policy_storage const*) @ 0x000000001184cedd 10. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001184858b 11. /build/src/IO/ReadWriteBufferFromHTTP.cpp:465: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x000000001184bf0b 12. /build/src/IO/ReadBuffer.h:60: DB::ReadBuffer::next() @ 0x000000000a148c7b 13. /build/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) @ 0x0000000011849fb2 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]>&)>&, 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&) @ 0x0000000011841980 15. /build/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) @ 0x000000001621208e 16. /build/src/Storages/StorageReplicatedMergeTree.cpp:5228: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl[abi:se190107] const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000015f9a5fe 17. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000015ed8bfd 18. /build/src/Storages/StorageReplicatedMergeTree.cpp:2514: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x0000000015ec9aab 19. /build/src/Storages/StorageReplicatedMergeTree.cpp:2349: DB::StorageReplicatedMergeTree::executeLogEntry(DB::ReplicatedMergeTreeLogEntry&) @ 0x0000000015eba91b 20. /build/src/Storages/StorageReplicatedMergeTree.cpp:3876: bool std::__function::__policy_invoker&)>::__call_impl[abi:se190107])::$_1, bool (std::shared_ptr&)>>(std::__function::__policy_storage const*, std::shared_ptr&) @ 0x0000000015f9837e 21. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000165d6fc3 22. /build/src/Storages/StorageReplicatedMergeTree.cpp:3872: DB::StorageReplicatedMergeTree::processQueueEntry(std::shared_ptr) @ 0x0000000015efc18a 23. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001624c1b2 24. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000162f9c70 25. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x00000000162fa55a 26. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc6653 27. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000000fccc4c3 28. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc3d92 29. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fcca080 30. ? @ 0x00007fbc6213eac3 31. ? @ 0x00007fbc621d0850 (version 25.3.6.10636.altinitytest (altinity build)) 2025.07.28 11:54:31.716321 [ 17611 ] {} 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. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception>&, String>(int, FormatStringHelperImpl>&>::type, std::type_identity::type>, std::basic_string_view>&, String&&) @ 0x000000001385a5eb 4. /build/src/Access/SettingsConstraints.cpp:376: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000013859b18 5. /build/src/Access/SettingsConstraints.cpp:300: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000013858faf 6. /build/src/Access/SettingsConstraints.cpp:209: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000013859223 7. /build/src/Interpreters/Context.cpp:2690: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000014436134 8. /build/src/Interpreters/Context.cpp:2729: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x000000001443662b 9. /build/src/Server/HTTPHandler.cpp:457: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000001686d165 10. /build/src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x0000000016870807 11. /build/src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x0000000016907e99 12. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 13. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 14. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 15. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 16. ? @ 0x00007fbc6213eac3 17. ? @ 0x00007fbc621d0850 (version 25.3.6.10636.altinitytest (altinity build)) 2025.07.28 11:54:32.003008 [ 3285 ] {096fb60c-c521-4f77-94f5-abec4a65351d} executeQuery: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION) (version 25.3.6.10636.altinitytest (altinity build)) (from [::1]:56376) (comment: 02834_array_exists_segfault.sql) (query 3, line 3) (in query: SET enable_analyzer = 0;), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x000000000c25bc4b 4. /build/src/Access/SettingsConstraints.cpp:343: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000138596e3 5. /build/src/Access/SettingsConstraints.cpp:300: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000013858faf 6. /build/src/Access/SettingsConstraints.cpp:194: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges const&, DB::SettingSource) const @ 0x00000000138591b3 7. /build/src/Interpreters/Context.cpp:2722: DB::Context::checkSettingsConstraints(DB::SettingsChanges const&, DB::SettingSource) @ 0x0000000014436509 8. /build/src/Interpreters/InterpreterSetQuery.cpp:28: DB::InterpreterSetQuery::execute() @ 0x00000000149e240a 9. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88dc9 10. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 11. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 12. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 13. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 14. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 16. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 17. ? @ 0x00007fbc6213eac3 18. ? @ 0x00007fbc621d0850 2025.07.28 11:54:32.013914 [ 3285 ] {} 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. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x000000000c25bc4b 4. /build/src/Access/SettingsConstraints.cpp:343: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000138596e3 5. /build/src/Access/SettingsConstraints.cpp:300: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000013858faf 6. /build/src/Access/SettingsConstraints.cpp:194: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges const&, DB::SettingSource) const @ 0x00000000138591b3 7. /build/src/Interpreters/Context.cpp:2722: DB::Context::checkSettingsConstraints(DB::SettingsChanges const&, DB::SettingSource) @ 0x0000000014436509 8. /build/src/Interpreters/InterpreterSetQuery.cpp:28: DB::InterpreterSetQuery::execute() @ 0x00000000149e240a 9. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88dc9 10. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 11. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 12. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 13. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 14. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 16. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 17. ? @ 0x00007fbc6213eac3 18. ? @ 0x00007fbc621d0850 2025.07.28 11:54:32.175198 [ 7625 ] {35fe62e3-f1bb-4ecd-8def-23ebd63b56ec} executeQuery: Code: 48. DB::Exception: For Replicated databases it's not allowed to execute ALTERs of different types (replicated and non replicated) in single query. (NOT_IMPLEMENTED) (version 25.3.6.10636.altinitytest (altinity build)) (from 0.0.0.0:0) (comment: 00725_comment_columns_long.sql) (in query: /* ddl_entry=query-0000000086 */ ALTER TABLE test_5.check_query_comment_column (MODIFY COLUMN `first_column` DEFAULT 1 COMMENT 'comment 1_3'), (MODIFY COLUMN `second_column` COMMENT 'comment 2_3'), (MODIFY COLUMN `third_column` DEFAULT 1 COMMENT 'comment 3_3')), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000000a074fcb 4. /build/src/Interpreters/InterpreterAlterQuery.cpp:199: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x00000000148df93e 5. /build/src/Interpreters/InterpreterAlterQuery.cpp:77: DB::InterpreterAlterQuery::execute() @ 0x00000000148dcb0d 6. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88dc9 7. /build/src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x0000000014c8ca7b 8. /build/src/Interpreters/DDLWorker.cpp:510: DB::DDLWorker::tryExecuteQuery(DB::DDLTaskBase&, std::shared_ptr const&, bool) @ 0x00000000144dab9e 9. /build/src/Interpreters/DDLWorker.cpp:675: DB::DDLWorker::processTask(DB::DDLTaskBase&, std::shared_ptr const&, bool) @ 0x00000000144d8ffe 10. /build/src/Databases/DatabaseReplicatedWorker.cpp:372: DB::DatabaseReplicatedDDLWorker::tryEnqueueAndExecuteEntry(DB::DDLLogEntry&, std::shared_ptr, bool) @ 0x0000000013dc29ab 11. /build/src/Databases/DatabaseReplicated.cpp:1139: DB::DatabaseReplicated::tryEnqueueReplicatedDDL(std::shared_ptr const&, std::shared_ptr, DB::QueryFlags) @ 0x0000000013d9f73c 12. /build/src/Interpreters/InterpreterAlterQuery.cpp:130: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x00000000148dd805 13. /build/src/Interpreters/InterpreterAlterQuery.cpp:77: DB::InterpreterAlterQuery::execute() @ 0x00000000148dcb0d 14. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88dc9 15. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 16. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 17. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 18. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 19. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 20. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 21. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 22. ? @ 0x00007fbc6213eac3 23. ? @ 0x00007fbc621d0850 2025.07.28 11:54:32.194088 [ 7625 ] {35fe62e3-f1bb-4ecd-8def-23ebd63b56ec} executeQuery: Code: 48. DB::Exception: For Replicated databases it's not allowed to execute ALTERs of different types (replicated and non replicated) in single query. (NOT_IMPLEMENTED) (version 25.3.6.10636.altinitytest (altinity build)) (from [::1]:48144) (comment: 00725_comment_columns_long.sql) (query 21, line 82) (in query: ALTER TABLE check_query_comment_column MODIFY COLUMN first_column DEFAULT 1 COMMENT 'comment 1_3', MODIFY COLUMN second_column COMMENT 'comment 2_3', -- We can't change default value of partition key. MODIFY COLUMN third_column DEFAULT 1 COMMENT 'comment 3_3';), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000000a074fcb 4. /build/src/Interpreters/InterpreterAlterQuery.cpp:199: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x00000000148df93e 5. /build/src/Interpreters/InterpreterAlterQuery.cpp:77: DB::InterpreterAlterQuery::execute() @ 0x00000000148dcb0d 6. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88dc9 7. /build/src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x0000000014c8ca7b 8. /build/src/Interpreters/DDLWorker.cpp:510: DB::DDLWorker::tryExecuteQuery(DB::DDLTaskBase&, std::shared_ptr const&, bool) @ 0x00000000144dab9e 9. /build/src/Interpreters/DDLWorker.cpp:675: DB::DDLWorker::processTask(DB::DDLTaskBase&, std::shared_ptr const&, bool) @ 0x00000000144d8ffe 10. /build/src/Databases/DatabaseReplicatedWorker.cpp:372: DB::DatabaseReplicatedDDLWorker::tryEnqueueAndExecuteEntry(DB::DDLLogEntry&, std::shared_ptr, bool) @ 0x0000000013dc29ab 11. /build/src/Databases/DatabaseReplicated.cpp:1139: DB::DatabaseReplicated::tryEnqueueReplicatedDDL(std::shared_ptr const&, std::shared_ptr, DB::QueryFlags) @ 0x0000000013d9f73c 12. /build/src/Interpreters/InterpreterAlterQuery.cpp:130: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x00000000148dd805 13. /build/src/Interpreters/InterpreterAlterQuery.cpp:77: DB::InterpreterAlterQuery::execute() @ 0x00000000148dcb0d 14. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88dc9 15. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 16. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 17. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 18. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 19. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 20. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 21. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 22. ? @ 0x00007fbc6213eac3 23. ? @ 0x00007fbc621d0850 2025.07.28 11:54:32.208360 [ 7625 ] {} TCPHandler: Code: 48. DB::Exception: For Replicated databases it's not allowed to execute ALTERs of different types (replicated and non replicated) in single query. (NOT_IMPLEMENTED), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000000a074fcb 4. /build/src/Interpreters/InterpreterAlterQuery.cpp:199: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x00000000148df93e 5. /build/src/Interpreters/InterpreterAlterQuery.cpp:77: DB::InterpreterAlterQuery::execute() @ 0x00000000148dcb0d 6. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88dc9 7. /build/src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x0000000014c8ca7b 8. /build/src/Interpreters/DDLWorker.cpp:510: DB::DDLWorker::tryExecuteQuery(DB::DDLTaskBase&, std::shared_ptr const&, bool) @ 0x00000000144dab9e 9. /build/src/Interpreters/DDLWorker.cpp:675: DB::DDLWorker::processTask(DB::DDLTaskBase&, std::shared_ptr const&, bool) @ 0x00000000144d8ffe 10. /build/src/Databases/DatabaseReplicatedWorker.cpp:372: DB::DatabaseReplicatedDDLWorker::tryEnqueueAndExecuteEntry(DB::DDLLogEntry&, std::shared_ptr, bool) @ 0x0000000013dc29ab 11. /build/src/Databases/DatabaseReplicated.cpp:1139: DB::DatabaseReplicated::tryEnqueueReplicatedDDL(std::shared_ptr const&, std::shared_ptr, DB::QueryFlags) @ 0x0000000013d9f73c 12. /build/src/Interpreters/InterpreterAlterQuery.cpp:130: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x00000000148dd805 13. /build/src/Interpreters/InterpreterAlterQuery.cpp:77: DB::InterpreterAlterQuery::execute() @ 0x00000000148dcb0d 14. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88dc9 15. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 16. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 17. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 18. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 19. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 20. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 21. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 22. ? @ 0x00007fbc6213eac3 23. ? @ 0x00007fbc621d0850 2025.07.28 11:54:32.325434 [ 17232 ] {6db0053b-072d-4930-90b5-6c1505b7601b} 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.6.10636.altinitytest (altinity build)) (from [::1]:48158) (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. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/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&&) @ 0x000000000a1011eb 4. /build/src/DataTypes/DataTypesDecimal.cpp:155: void DB::convertDecimalsImpl>, DB::DataTypeDecimal>, void>(T::FieldType const&, unsigned int, unsigned int, T0::FieldType&) @ 0x0000000013c1e6d8 5. /build/src/DataTypes/DataTypesDecimal.cpp:308: T0::FieldType DB::convertToDecimal, DB::DataTypeDecimal>>(T::FieldType const&, unsigned int) @ 0x0000000013c32a9e 6. /build/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) @ 0x0000000013102f95 7. /build/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 @ 0x00000000130fca84 8. /build/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&&) @ 0x0000000012fad179 9. /build/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 @ 0x0000000012fce44e 10. /build/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 @ 0x0000000012fcdc7a 11. /build/src/Functions/IFunction.h:437: DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000a069f2a 12. /build/src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000012d9965a 13. /build/src/Functions/IFunction.cpp:351: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d93b02 14. /build/src/Functions/IFunction.cpp:177: DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d93698 15. /build/src/Functions/IFunction.cpp:343: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d93aad 16. /build/src/Functions/IFunction.cpp:420: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d95059 17. /build/src/Functions/IFunction.cpp:498: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d95c72 18. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3567: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000014034494 19. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3838: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000014019a9e 20. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3980: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000014018e31 21. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:2925: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000001402fcbd 22. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3838: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000014019a9e 23. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3980: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000014018e31 24. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:4304: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000014042fa7 25. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5605: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000014013749 26. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000140127f9 27. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000014011fce 28. /build/src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000001406ce8a 29. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000014973b42 30. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000001497268d 31. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000014974d24 2025.07.28 11:54:32.344995 [ 17232 ] {} 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. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/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&&) @ 0x000000000a1011eb 4. /build/src/DataTypes/DataTypesDecimal.cpp:155: void DB::convertDecimalsImpl>, DB::DataTypeDecimal>, void>(T::FieldType const&, unsigned int, unsigned int, T0::FieldType&) @ 0x0000000013c1e6d8 5. /build/src/DataTypes/DataTypesDecimal.cpp:308: T0::FieldType DB::convertToDecimal, DB::DataTypeDecimal>>(T::FieldType const&, unsigned int) @ 0x0000000013c32a9e 6. /build/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) @ 0x0000000013102f95 7. /build/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 @ 0x00000000130fca84 8. /build/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&&) @ 0x0000000012fad179 9. /build/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 @ 0x0000000012fce44e 10. /build/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 @ 0x0000000012fcdc7a 11. /build/src/Functions/IFunction.h:437: DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000a069f2a 12. /build/src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000012d9965a 13. /build/src/Functions/IFunction.cpp:351: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d93b02 14. /build/src/Functions/IFunction.cpp:177: DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d93698 15. /build/src/Functions/IFunction.cpp:343: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d93aad 16. /build/src/Functions/IFunction.cpp:420: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d95059 17. /build/src/Functions/IFunction.cpp:498: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d95c72 18. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3567: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000014034494 19. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3838: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000014019a9e 20. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3980: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000014018e31 21. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:2925: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000001402fcbd 22. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3838: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000014019a9e 23. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3980: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000014018e31 24. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:4304: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000014042fa7 25. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5605: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000014013749 26. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000140127f9 27. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000014011fce 28. /build/src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000001406ce8a 29. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000014973b42 30. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000001497268d 31. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000014974d24 2025.07.28 11:54:32.489718 [ 17611 ] {a934419f-61c1-4c5f-9812-db70ed2843e5} executeQuery: Code: 43. DB::Exception: A value of illegal type was provided as 1st argument 'array_1' to function 'arrayJaccardIndex'. Expected: Array, got: String: In scope SELECT 'a' AS arr1, 2 AS arr2, round(arrayJaccardIndex(arr1, arr2), 2). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.6.10636.altinitytest (altinity build)) (from [::1]:56394) (comment: 02737_arrayJaccardIndex.sql) (query 2, line 3) (in query: SELECT 'a' AS arr1, 2 AS arr2, round(arrayJaccardIndex(arr1, arr2), 2);), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: 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&&) @ 0x0000000012da74d9 4. /build/src/Functions/FunctionHelpers.cpp:130: DB::(anonymous namespace)::validateArgumentsImpl(DB::IFunction const&, std::vector> const&, unsigned long, std::vector> const&) @ 0x0000000012da5b15 5. /build/src/Functions/FunctionHelpers.cpp:192: DB::validateFunctionArguments(DB::IFunction const&, std::vector> const&, std::vector> const&, std::vector> const&) @ 0x0000000012da54fb 6. /build/src/Functions/array/arrayJaccardIndex.cpp:90: DB::FunctionArrayJaccardIndex::getReturnTypeImpl(std::vector> const&) const @ 0x000000000f5a0c46 7. /build/src/Functions/IFunction.cpp:645: DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x0000000012d96b0c 8. /build/src/Functions/IFunction.cpp:577: DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x0000000012d9669c 9. /build/src/Functions/IFunction.cpp:606: DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x0000000012d96edc 10. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3544: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000014033cc9 11. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3838: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000014019a9e 12. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3980: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000014018e31 13. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:2925: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000001402fcbd 14. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3838: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000014019a9e 15. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3980: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000014018e31 16. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:4304: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000014042fa7 17. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5605: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000014013749 18. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000140127f9 19. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000014011fce 20. /build/src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000001406ce8a 21. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000014973b42 22. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000001497268d 23. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000014974d24 24. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001492924b 25. /build/src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88641 26. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 27. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 28. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 29. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 30. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 31. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 2025.07.28 11:54:32.494990 [ 17611 ] {} TCPHandler: Code: 43. DB::Exception: A value of illegal type was provided as 1st argument 'array_1' to function 'arrayJaccardIndex'. Expected: Array, got: String: In scope SELECT 'a' AS arr1, 2 AS arr2, round(arrayJaccardIndex(arr1, arr2), 2). (ILLEGAL_TYPE_OF_ARGUMENT), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: 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&&) @ 0x0000000012da74d9 4. /build/src/Functions/FunctionHelpers.cpp:130: DB::(anonymous namespace)::validateArgumentsImpl(DB::IFunction const&, std::vector> const&, unsigned long, std::vector> const&) @ 0x0000000012da5b15 5. /build/src/Functions/FunctionHelpers.cpp:192: DB::validateFunctionArguments(DB::IFunction const&, std::vector> const&, std::vector> const&, std::vector> const&) @ 0x0000000012da54fb 6. /build/src/Functions/array/arrayJaccardIndex.cpp:90: DB::FunctionArrayJaccardIndex::getReturnTypeImpl(std::vector> const&) const @ 0x000000000f5a0c46 7. /build/src/Functions/IFunction.cpp:645: DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x0000000012d96b0c 8. /build/src/Functions/IFunction.cpp:577: DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x0000000012d9669c 9. /build/src/Functions/IFunction.cpp:606: DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x0000000012d96edc 10. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3544: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000014033cc9 11. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3838: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000014019a9e 12. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3980: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000014018e31 13. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:2925: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000001402fcbd 14. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3838: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000014019a9e 15. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3980: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000014018e31 16. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:4304: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000014042fa7 17. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5605: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000014013749 18. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000140127f9 19. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000014011fce 20. /build/src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000001406ce8a 21. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000014973b42 22. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000001497268d 23. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000014974d24 24. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001492924b 25. /build/src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88641 26. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 27. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 28. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 29. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 30. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 31. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 2025.07.28 11:54:32.595834 [ 17611 ] {2c9aa687-e23f-4e07-b99c-0ad5c296926b} executeQuery: Code: 43. DB::Exception: array aggregate functions cannot be performed on two empty arrays: In scope SELECT [] AS arr1, [] AS arr2, round(arrayJaccardIndex(arr1, arr2), 2). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.6.10636.altinitytest (altinity build)) (from [::1]:56394) (comment: 02737_arrayJaccardIndex.sql) (query 3, line 4) (in query: SELECT [] AS arr1, [] AS arr2, round(arrayJaccardIndex(arr1, arr2), 2);), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000000a074fcb 4. /build/src/Functions/array/arrayJaccardIndex.cpp:70: void DB::FunctionArrayJaccardIndex::vectorWithEmptyIntersect(DB::PODArray, 63ul, 64ul> const&, DB::PODArray, 63ul, 64ul> const&, DB::PODArray, 63ul, 64ul>&) @ 0x000000000f5a0ff5 5. /build/src/Functions/array/arrayJaccardIndex.cpp:136: DB::FunctionArrayJaccardIndex::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000f5a06b0 6. /build/src/Functions/IFunction.h:437: DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000a069f2a 7. /build/src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000012d9965a 8. /build/src/Functions/IFunction.cpp:351: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d93b02 9. /build/src/Functions/IFunction.cpp:177: DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d93698 10. /build/src/Functions/IFunction.cpp:343: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d93aad 11. /build/src/Functions/IFunction.cpp:420: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d95059 12. /build/src/Functions/IFunction.cpp:498: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d95c72 13. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3567: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000014034494 14. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3838: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000014019a9e 15. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3980: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000014018e31 16. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:2925: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000001402fcbd 17. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3838: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000014019a9e 18. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3980: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000014018e31 19. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:4304: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000014042fa7 20. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5605: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000014013749 21. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000140127f9 22. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000014011fce 23. /build/src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000001406ce8a 24. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000014973b42 25. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000001497268d 26. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000014974d24 27. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001492924b 28. /build/src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88641 29. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 30. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 31. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 2025.07.28 11:54:32.599985 [ 17611 ] {} TCPHandler: Code: 43. DB::Exception: array aggregate functions cannot be performed on two empty arrays: In scope SELECT [] AS arr1, [] AS arr2, round(arrayJaccardIndex(arr1, arr2), 2). (ILLEGAL_TYPE_OF_ARGUMENT), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000000a074fcb 4. /build/src/Functions/array/arrayJaccardIndex.cpp:70: void DB::FunctionArrayJaccardIndex::vectorWithEmptyIntersect(DB::PODArray, 63ul, 64ul> const&, DB::PODArray, 63ul, 64ul> const&, DB::PODArray, 63ul, 64ul>&) @ 0x000000000f5a0ff5 5. /build/src/Functions/array/arrayJaccardIndex.cpp:136: DB::FunctionArrayJaccardIndex::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000f5a06b0 6. /build/src/Functions/IFunction.h:437: DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000a069f2a 7. /build/src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000012d9965a 8. /build/src/Functions/IFunction.cpp:351: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d93b02 9. /build/src/Functions/IFunction.cpp:177: DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d93698 10. /build/src/Functions/IFunction.cpp:343: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d93aad 11. /build/src/Functions/IFunction.cpp:420: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d95059 12. /build/src/Functions/IFunction.cpp:498: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d95c72 13. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3567: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000014034494 14. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3838: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000014019a9e 15. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3980: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000014018e31 16. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:2925: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000001402fcbd 17. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3838: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000014019a9e 18. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3980: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000014018e31 19. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:4304: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000014042fa7 20. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5605: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000014013749 21. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000140127f9 22. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000014011fce 23. /build/src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000001406ce8a 24. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000014973b42 25. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000001497268d 26. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000014974d24 27. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001492924b 28. /build/src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88641 29. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 30. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 31. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 2025.07.28 11:54:32.611041 [ 3960 ] {} test_13.rmt2 (7f9b740d-015c-470e-8cc6-8ba33be0dc63): auto DB::StorageReplicatedMergeTree::processQueueEntry(ReplicatedMergeTreeQueue::SelectedEntryPtr)::(anonymous class)::operator()(LogEntryPtr &) const: Code: 86. DB::HTTPException: Received error from remote server http://146b4357c08d:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Ftest%2F01165%2Ftest_13%2Frmt%2Freplicas%2F1&part=20250728_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.6.10636.altinitytest (altinity build)) '. (RECEIVED_ERROR_FROM_REMOTE_IO_SERVER), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.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 const&, int&&, String const&, unsigned long&&, String const&) @ 0x000000000feda8d9 4. /build/src/IO/HTTPCommon.cpp:104: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x000000000feda6e2 5. /build/src/IO/HTTPCommon.cpp:93: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x000000000feda537 6. /build/src/IO/ReadWriteBufferFromHTTP.cpp:277: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x000000001184a4c4 7. /build/src/IO/ReadWriteBufferFromHTTP.cpp:285: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x000000001184a615 8. /build/src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x000000001184ae59 9. /build/src/IO/ReadWriteBufferFromHTTP.cpp:472: void std::__function::__policy_invoker::__call_impl[abi:se190107]>(std::__function::__policy_storage const*) @ 0x000000001184cedd 10. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001184858b 11. /build/src/IO/ReadWriteBufferFromHTTP.cpp:465: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x000000001184bf0b 12. /build/src/IO/ReadBuffer.h:60: DB::ReadBuffer::next() @ 0x000000000a148c7b 13. /build/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) @ 0x0000000011849fb2 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]>&)>&, 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&) @ 0x0000000011841980 15. /build/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) @ 0x000000001621208e 16. /build/src/Storages/StorageReplicatedMergeTree.cpp:5228: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl[abi:se190107] const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000015f9a5fe 17. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000015ed8bfd 18. /build/src/Storages/StorageReplicatedMergeTree.cpp:2514: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x0000000015ec9aab 19. /build/src/Storages/StorageReplicatedMergeTree.cpp:2349: DB::StorageReplicatedMergeTree::executeLogEntry(DB::ReplicatedMergeTreeLogEntry&) @ 0x0000000015eba91b 20. /build/src/Storages/StorageReplicatedMergeTree.cpp:3876: bool std::__function::__policy_invoker&)>::__call_impl[abi:se190107])::$_1, bool (std::shared_ptr&)>>(std::__function::__policy_storage const*, std::shared_ptr&) @ 0x0000000015f9837e 21. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000165d6fc3 22. /build/src/Storages/StorageReplicatedMergeTree.cpp:3872: DB::StorageReplicatedMergeTree::processQueueEntry(std::shared_ptr) @ 0x0000000015efc18a 23. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001624c1b2 24. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000162f9c70 25. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x00000000162fa55a 26. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc6653 27. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000000fccc4c3 28. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc3d92 29. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fcca080 30. ? @ 0x00007fbc6213eac3 31. ? @ 0x00007fbc621d0850 (version 25.3.6.10636.altinitytest (altinity build)) 2025.07.28 11:54:32.697281 [ 17611 ] {e0d5edd0-f1ea-4b27-9540-2db1edb690cd} executeQuery: Code: 386. DB::Exception: There is no subtype for types String, UInt8 because some of them are String/FixedString and some of them are not: In scope SELECT ['1', '2'] AS arr1, [1, 2] AS arr2, round(arrayJaccardIndex(arr1, arr2), 2). (NO_COMMON_TYPE) (version 25.3.6.10636.altinitytest (altinity build)) (from [::1]:56394) (comment: 02737_arrayJaccardIndex.sql) (query 4, line 5) (in query: SELECT ['1', '2'] AS arr1, [1,2] AS arr2, round(arrayJaccardIndex(arr1, arr2), 2);), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:111: DB::Exception::createDeprecated(String const&, int, bool) @ 0x000000000a08e96d 3. /build/src/DataTypes/getMostSubtype.cpp:53: DB::getMostSubtype(std::vector, std::allocator>> const&, bool, bool)::$_0::operator()(String const&) const @ 0x0000000013c752f2 4. /build/src/DataTypes/getMostSubtype.cpp:232: DB::getMostSubtype(std::vector, std::allocator>> const&, bool, bool) @ 0x0000000013c745cc 5. /build/src/Functions/array/arrayIntersect.cpp:206: DB::FunctionArrayIntersect::getReturnTypeImpl(std::vector, std::allocator>> const&) const @ 0x000000000f5407f8 6. /build/src/Functions/IFunction.h:520: DB::IFunction::getReturnTypeImpl(std::vector> const&) const @ 0x000000000a06a2de 7. /build/src/Functions/IFunction.cpp:645: DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x0000000012d96b0c 8. /build/src/Functions/IFunction.cpp:577: DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x0000000012d9669c 9. /build/src/Functions/IFunction.cpp:606: DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x0000000012d96edc 10. /build/src/Functions/array/arrayJaccardIndex.cpp:112: DB::FunctionArrayJaccardIndex::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000f5a02bb 11. /build/src/Functions/IFunction.h:437: DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000a069f2a 12. /build/src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000012d9965a 13. /build/src/Functions/IFunction.cpp:351: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d93b02 14. /build/src/Functions/IFunction.cpp:177: DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d93698 15. /build/src/Functions/IFunction.cpp:343: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d93aad 16. /build/src/Functions/IFunction.cpp:420: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d95059 17. /build/src/Functions/IFunction.cpp:498: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d95c72 18. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3567: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000014034494 19. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3838: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000014019a9e 20. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3980: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000014018e31 21. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:2925: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000001402fcbd 22. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3838: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000014019a9e 23. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3980: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000014018e31 24. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:4304: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000014042fa7 25. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5605: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000014013749 26. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000140127f9 27. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000014011fce 28. /build/src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000001406ce8a 29. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000014973b42 30. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000001497268d 31. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000014974d24 2025.07.28 11:54:32.701987 [ 17611 ] {} TCPHandler: Code: 386. DB::Exception: There is no subtype for types String, UInt8 because some of them are String/FixedString and some of them are not: In scope SELECT ['1', '2'] AS arr1, [1, 2] AS arr2, round(arrayJaccardIndex(arr1, arr2), 2). (NO_COMMON_TYPE), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:111: DB::Exception::createDeprecated(String const&, int, bool) @ 0x000000000a08e96d 3. /build/src/DataTypes/getMostSubtype.cpp:53: DB::getMostSubtype(std::vector, std::allocator>> const&, bool, bool)::$_0::operator()(String const&) const @ 0x0000000013c752f2 4. /build/src/DataTypes/getMostSubtype.cpp:232: DB::getMostSubtype(std::vector, std::allocator>> const&, bool, bool) @ 0x0000000013c745cc 5. /build/src/Functions/array/arrayIntersect.cpp:206: DB::FunctionArrayIntersect::getReturnTypeImpl(std::vector, std::allocator>> const&) const @ 0x000000000f5407f8 6. /build/src/Functions/IFunction.h:520: DB::IFunction::getReturnTypeImpl(std::vector> const&) const @ 0x000000000a06a2de 7. /build/src/Functions/IFunction.cpp:645: DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x0000000012d96b0c 8. /build/src/Functions/IFunction.cpp:577: DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x0000000012d9669c 9. /build/src/Functions/IFunction.cpp:606: DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x0000000012d96edc 10. /build/src/Functions/array/arrayJaccardIndex.cpp:112: DB::FunctionArrayJaccardIndex::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000f5a02bb 11. /build/src/Functions/IFunction.h:437: DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000a069f2a 12. /build/src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000012d9965a 13. /build/src/Functions/IFunction.cpp:351: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d93b02 14. /build/src/Functions/IFunction.cpp:177: DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d93698 15. /build/src/Functions/IFunction.cpp:343: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d93aad 16. /build/src/Functions/IFunction.cpp:420: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d95059 17. /build/src/Functions/IFunction.cpp:498: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d95c72 18. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3567: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000014034494 19. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3838: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000014019a9e 20. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3980: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000014018e31 21. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:2925: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000001402fcbd 22. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3838: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000014019a9e 23. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3980: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000014018e31 24. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:4304: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000014042fa7 25. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5605: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000014013749 26. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000140127f9 27. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000014011fce 28. /build/src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000001406ce8a 29. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000014973b42 30. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000001497268d 31. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000014974d24 2025.07.28 11:54:32.874864 [ 3965 ] {} test_13.rmt2 (7f9b740d-015c-470e-8cc6-8ba33be0dc63): auto DB::StorageReplicatedMergeTree::processQueueEntry(ReplicatedMergeTreeQueue::SelectedEntryPtr)::(anonymous class)::operator()(LogEntryPtr &) const: Code: 86. DB::HTTPException: Received error from remote server http://146b4357c08d:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Ftest%2F01165%2Ftest_13%2Frmt%2Freplicas%2F1&part=20250728_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.6.10636.altinitytest (altinity build)) '. (RECEIVED_ERROR_FROM_REMOTE_IO_SERVER), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.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 const&, int&&, String const&, unsigned long&&, String const&) @ 0x000000000feda8d9 4. /build/src/IO/HTTPCommon.cpp:104: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x000000000feda6e2 5. /build/src/IO/HTTPCommon.cpp:93: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x000000000feda537 6. /build/src/IO/ReadWriteBufferFromHTTP.cpp:277: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x000000001184a4c4 7. /build/src/IO/ReadWriteBufferFromHTTP.cpp:285: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x000000001184a615 8. /build/src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x000000001184ae59 9. /build/src/IO/ReadWriteBufferFromHTTP.cpp:472: void std::__function::__policy_invoker::__call_impl[abi:se190107]>(std::__function::__policy_storage const*) @ 0x000000001184cedd 10. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001184858b 11. /build/src/IO/ReadWriteBufferFromHTTP.cpp:465: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x000000001184bf0b 12. /build/src/IO/ReadBuffer.h:60: DB::ReadBuffer::next() @ 0x000000000a148c7b 13. /build/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) @ 0x0000000011849fb2 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]>&)>&, 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&) @ 0x0000000011841980 15. /build/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) @ 0x000000001621208e 16. /build/src/Storages/StorageReplicatedMergeTree.cpp:5228: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl[abi:se190107] const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000015f9a5fe 17. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000015ed8bfd 18. /build/src/Storages/StorageReplicatedMergeTree.cpp:2514: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x0000000015ec9aab 19. /build/src/Storages/StorageReplicatedMergeTree.cpp:2349: DB::StorageReplicatedMergeTree::executeLogEntry(DB::ReplicatedMergeTreeLogEntry&) @ 0x0000000015eba91b 20. /build/src/Storages/StorageReplicatedMergeTree.cpp:3876: bool std::__function::__policy_invoker&)>::__call_impl[abi:se190107])::$_1, bool (std::shared_ptr&)>>(std::__function::__policy_storage const*, std::shared_ptr&) @ 0x0000000015f9837e 21. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000165d6fc3 22. /build/src/Storages/StorageReplicatedMergeTree.cpp:3872: DB::StorageReplicatedMergeTree::processQueueEntry(std::shared_ptr) @ 0x0000000015efc18a 23. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001624c1b2 24. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000162f9c70 25. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x00000000162fa55a 26. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc6653 27. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000000fccc4c3 28. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc3d92 29. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fcca080 30. ? @ 0x00007fbc6213eac3 31. ? @ 0x00007fbc621d0850 (version 25.3.6.10636.altinitytest (altinity build)) 2025.07.28 11:54:32.985741 [ 17256 ] {} 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. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception>&, String>(int, FormatStringHelperImpl>&>::type, std::type_identity::type>, std::basic_string_view>&, String&&) @ 0x000000001385a5eb 4. /build/src/Access/SettingsConstraints.cpp:376: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000013859b18 5. /build/src/Access/SettingsConstraints.cpp:300: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000013858faf 6. /build/src/Access/SettingsConstraints.cpp:209: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000013859223 7. /build/src/Interpreters/Context.cpp:2690: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000014436134 8. /build/src/Interpreters/Context.cpp:2729: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x000000001443662b 9. /build/src/Server/HTTPHandler.cpp:457: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000001686d165 10. /build/src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x0000000016870807 11. /build/src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x0000000016907e99 12. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 13. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 14. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 15. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 16. ? @ 0x00007fbc6213eac3 17. ? @ 0x00007fbc621d0850 (version 25.3.6.10636.altinitytest (altinity build)) 2025.07.28 11:54:33.151238 [ 3961 ] {} test_13.rmt2 (7f9b740d-015c-470e-8cc6-8ba33be0dc63): auto DB::StorageReplicatedMergeTree::processQueueEntry(ReplicatedMergeTreeQueue::SelectedEntryPtr)::(anonymous class)::operator()(LogEntryPtr &) const: Code: 86. DB::HTTPException: Received error from remote server http://146b4357c08d:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Ftest%2F01165%2Ftest_13%2Frmt%2Freplicas%2F1&part=20250728_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.6.10636.altinitytest (altinity build)) '. (RECEIVED_ERROR_FROM_REMOTE_IO_SERVER), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.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 const&, int&&, String const&, unsigned long&&, String const&) @ 0x000000000feda8d9 4. /build/src/IO/HTTPCommon.cpp:104: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x000000000feda6e2 5. /build/src/IO/HTTPCommon.cpp:93: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x000000000feda537 6. /build/src/IO/ReadWriteBufferFromHTTP.cpp:277: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x000000001184a4c4 7. /build/src/IO/ReadWriteBufferFromHTTP.cpp:285: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x000000001184a615 8. /build/src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x000000001184ae59 9. /build/src/IO/ReadWriteBufferFromHTTP.cpp:472: void std::__function::__policy_invoker::__call_impl[abi:se190107]>(std::__function::__policy_storage const*) @ 0x000000001184cedd 10. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001184858b 11. /build/src/IO/ReadWriteBufferFromHTTP.cpp:465: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x000000001184bf0b 12. /build/src/IO/ReadBuffer.h:60: DB::ReadBuffer::next() @ 0x000000000a148c7b 13. /build/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) @ 0x0000000011849fb2 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]>&)>&, 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&) @ 0x0000000011841980 15. /build/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) @ 0x000000001621208e 16. /build/src/Storages/StorageReplicatedMergeTree.cpp:5228: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl[abi:se190107] const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000015f9a5fe 17. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000015ed8bfd 18. /build/src/Storages/StorageReplicatedMergeTree.cpp:2514: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x0000000015ec9aab 19. /build/src/Storages/StorageReplicatedMergeTree.cpp:2349: DB::StorageReplicatedMergeTree::executeLogEntry(DB::ReplicatedMergeTreeLogEntry&) @ 0x0000000015eba91b 20. /build/src/Storages/StorageReplicatedMergeTree.cpp:3876: bool std::__function::__policy_invoker&)>::__call_impl[abi:se190107])::$_1, bool (std::shared_ptr&)>>(std::__function::__policy_storage const*, std::shared_ptr&) @ 0x0000000015f9837e 21. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000165d6fc3 22. /build/src/Storages/StorageReplicatedMergeTree.cpp:3872: DB::StorageReplicatedMergeTree::processQueueEntry(std::shared_ptr) @ 0x0000000015efc18a 23. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001624c1b2 24. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000162f9c70 25. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x00000000162fa55a 26. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc6653 27. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000000fccc4c3 28. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc3d92 29. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fcca080 30. ? @ 0x00007fbc6213eac3 31. ? @ 0x00007fbc621d0850 (version 25.3.6.10636.altinitytest (altinity build)) 2025.07.28 11:54:33.710577 [ 3966 ] {} test_13.rmt2 (7f9b740d-015c-470e-8cc6-8ba33be0dc63): auto DB::StorageReplicatedMergeTree::processQueueEntry(ReplicatedMergeTreeQueue::SelectedEntryPtr)::(anonymous class)::operator()(LogEntryPtr &) const: Code: 86. DB::HTTPException: Received error from remote server http://146b4357c08d:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Ftest%2F01165%2Ftest_13%2Frmt%2Freplicas%2F1&part=20250728_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.6.10636.altinitytest (altinity build)) '. (RECEIVED_ERROR_FROM_REMOTE_IO_SERVER), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.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 const&, int&&, String const&, unsigned long&&, String const&) @ 0x000000000feda8d9 4. /build/src/IO/HTTPCommon.cpp:104: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x000000000feda6e2 5. /build/src/IO/HTTPCommon.cpp:93: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x000000000feda537 6. /build/src/IO/ReadWriteBufferFromHTTP.cpp:277: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x000000001184a4c4 7. /build/src/IO/ReadWriteBufferFromHTTP.cpp:285: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x000000001184a615 8. /build/src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x000000001184ae59 9. /build/src/IO/ReadWriteBufferFromHTTP.cpp:472: void std::__function::__policy_invoker::__call_impl[abi:se190107]>(std::__function::__policy_storage const*) @ 0x000000001184cedd 10. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001184858b 11. /build/src/IO/ReadWriteBufferFromHTTP.cpp:465: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x000000001184bf0b 12. /build/src/IO/ReadBuffer.h:60: DB::ReadBuffer::next() @ 0x000000000a148c7b 13. /build/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) @ 0x0000000011849fb2 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]>&)>&, 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&) @ 0x0000000011841980 15. /build/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) @ 0x000000001621208e 16. /build/src/Storages/StorageReplicatedMergeTree.cpp:5228: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl[abi:se190107] const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000015f9a5fe 17. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000015ed8bfd 18. /build/src/Storages/StorageReplicatedMergeTree.cpp:2514: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x0000000015ec9aab 19. /build/src/Storages/StorageReplicatedMergeTree.cpp:2349: DB::StorageReplicatedMergeTree::executeLogEntry(DB::ReplicatedMergeTreeLogEntry&) @ 0x0000000015eba91b 20. /build/src/Storages/StorageReplicatedMergeTree.cpp:3876: bool std::__function::__policy_invoker&)>::__call_impl[abi:se190107])::$_1, bool (std::shared_ptr&)>>(std::__function::__policy_storage const*, std::shared_ptr&) @ 0x0000000015f9837e 21. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000165d6fc3 22. /build/src/Storages/StorageReplicatedMergeTree.cpp:3872: DB::StorageReplicatedMergeTree::processQueueEntry(std::shared_ptr) @ 0x0000000015efc18a 23. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001624c1b2 24. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000162f9c70 25. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x00000000162fa55a 26. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc6653 27. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000000fccc4c3 28. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc3d92 29. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fcca080 30. ? @ 0x00007fbc6213eac3 31. ? @ 0x00007fbc621d0850 (version 25.3.6.10636.altinitytest (altinity build)) 2025.07.28 11:54:34.303938 [ 3972 ] {} test_13.rmt2 (7f9b740d-015c-470e-8cc6-8ba33be0dc63): auto DB::StorageReplicatedMergeTree::processQueueEntry(ReplicatedMergeTreeQueue::SelectedEntryPtr)::(anonymous class)::operator()(LogEntryPtr &) const: Code: 86. DB::HTTPException: Received error from remote server http://146b4357c08d:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Ftest%2F01165%2Ftest_13%2Frmt%2Freplicas%2F1&part=20250728_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.6.10636.altinitytest (altinity build)) '. (RECEIVED_ERROR_FROM_REMOTE_IO_SERVER), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.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 const&, int&&, String const&, unsigned long&&, String const&) @ 0x000000000feda8d9 4. /build/src/IO/HTTPCommon.cpp:104: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x000000000feda6e2 5. /build/src/IO/HTTPCommon.cpp:93: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x000000000feda537 6. /build/src/IO/ReadWriteBufferFromHTTP.cpp:277: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x000000001184a4c4 7. /build/src/IO/ReadWriteBufferFromHTTP.cpp:285: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x000000001184a615 8. /build/src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x000000001184ae59 9. /build/src/IO/ReadWriteBufferFromHTTP.cpp:472: void std::__function::__policy_invoker::__call_impl[abi:se190107]>(std::__function::__policy_storage const*) @ 0x000000001184cedd 10. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001184858b 11. /build/src/IO/ReadWriteBufferFromHTTP.cpp:465: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x000000001184bf0b 12. /build/src/IO/ReadBuffer.h:60: DB::ReadBuffer::next() @ 0x000000000a148c7b 13. /build/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) @ 0x0000000011849fb2 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]>&)>&, 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&) @ 0x0000000011841980 15. /build/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) @ 0x000000001621208e 16. /build/src/Storages/StorageReplicatedMergeTree.cpp:5228: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl[abi:se190107] const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000015f9a5fe 17. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000015ed8bfd 18. /build/src/Storages/StorageReplicatedMergeTree.cpp:2514: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x0000000015ec9aab 19. /build/src/Storages/StorageReplicatedMergeTree.cpp:2349: DB::StorageReplicatedMergeTree::executeLogEntry(DB::ReplicatedMergeTreeLogEntry&) @ 0x0000000015eba91b 20. /build/src/Storages/StorageReplicatedMergeTree.cpp:3876: bool std::__function::__policy_invoker&)>::__call_impl[abi:se190107])::$_1, bool (std::shared_ptr&)>>(std::__function::__policy_storage const*, std::shared_ptr&) @ 0x0000000015f9837e 21. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000165d6fc3 22. /build/src/Storages/StorageReplicatedMergeTree.cpp:3872: DB::StorageReplicatedMergeTree::processQueueEntry(std::shared_ptr) @ 0x0000000015efc18a 23. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001624c1b2 24. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000162f9c70 25. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x00000000162fa55a 26. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc6653 27. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000000fccc4c3 28. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc3d92 29. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fcca080 30. ? @ 0x00007fbc6213eac3 31. ? @ 0x00007fbc621d0850 (version 25.3.6.10636.altinitytest (altinity build)) 2025.07.28 11:54:35.118986 [ 3963 ] {} test_13.rmt2 (7f9b740d-015c-470e-8cc6-8ba33be0dc63): auto DB::StorageReplicatedMergeTree::processQueueEntry(ReplicatedMergeTreeQueue::SelectedEntryPtr)::(anonymous class)::operator()(LogEntryPtr &) const: Code: 86. DB::HTTPException: Received error from remote server http://146b4357c08d:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Ftest%2F01165%2Ftest_13%2Frmt%2Freplicas%2F1&part=20250728_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.6.10636.altinitytest (altinity build)) '. (RECEIVED_ERROR_FROM_REMOTE_IO_SERVER), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.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 const&, int&&, String const&, unsigned long&&, String const&) @ 0x000000000feda8d9 4. /build/src/IO/HTTPCommon.cpp:104: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x000000000feda6e2 5. /build/src/IO/HTTPCommon.cpp:93: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x000000000feda537 6. /build/src/IO/ReadWriteBufferFromHTTP.cpp:277: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x000000001184a4c4 7. /build/src/IO/ReadWriteBufferFromHTTP.cpp:285: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x000000001184a615 8. /build/src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x000000001184ae59 9. /build/src/IO/ReadWriteBufferFromHTTP.cpp:472: void std::__function::__policy_invoker::__call_impl[abi:se190107]>(std::__function::__policy_storage const*) @ 0x000000001184cedd 10. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001184858b 11. /build/src/IO/ReadWriteBufferFromHTTP.cpp:465: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x000000001184bf0b 12. /build/src/IO/ReadBuffer.h:60: DB::ReadBuffer::next() @ 0x000000000a148c7b 13. /build/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) @ 0x0000000011849fb2 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]>&)>&, 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&) @ 0x0000000011841980 15. /build/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) @ 0x000000001621208e 16. /build/src/Storages/StorageReplicatedMergeTree.cpp:5228: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl[abi:se190107] const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000015f9a5fe 17. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000015ed8bfd 18. /build/src/Storages/StorageReplicatedMergeTree.cpp:2514: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x0000000015ec9aab 19. /build/src/Storages/StorageReplicatedMergeTree.cpp:2349: DB::StorageReplicatedMergeTree::executeLogEntry(DB::ReplicatedMergeTreeLogEntry&) @ 0x0000000015eba91b 20. /build/src/Storages/StorageReplicatedMergeTree.cpp:3876: bool std::__function::__policy_invoker&)>::__call_impl[abi:se190107])::$_1, bool (std::shared_ptr&)>>(std::__function::__policy_storage const*, std::shared_ptr&) @ 0x0000000015f9837e 21. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000165d6fc3 22. /build/src/Storages/StorageReplicatedMergeTree.cpp:3872: DB::StorageReplicatedMergeTree::processQueueEntry(std::shared_ptr) @ 0x0000000015efc18a 23. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001624c1b2 24. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000162f9c70 25. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x00000000162fa55a 26. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc6653 27. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000000fccc4c3 28. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc3d92 29. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fcca080 30. ? @ 0x00007fbc6213eac3 31. ? @ 0x00007fbc621d0850 (version 25.3.6.10636.altinitytest (altinity build)) 2025.07.28 11:54:35.314378 [ 4963 ] {bfd1ca0f-6232-467d-920b-d22c8b2924c4} executeQuery: Code: 10. DB::Exception: Not found column toUInt128(__table2.id): in block __table2.id UUID UUID(size = 0). (NOT_FOUND_COLUMN_IN_BLOCK) (version 25.3.6.10636.altinitytest (altinity build)) (from [::1]:56458) (comment: 03393_join_bug_77848.sql) (query 8, line 11) (in query: -- TODO(@vdimir): NOT_FOUND_COLUMN_IN_BLOCK is a bug, should be fixed -- This tests ensures that query does not crash at least SELECT 1 FROM BadTable i LEFT JOIN BadJoin c ON i.id_uint = toUInt128(c.id) WHERE equals(i.id_uint, 12);), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000a9b78ab 4. /build/src/Interpreters/ActionsDAG.cpp:977: DB::ActionsDAG::evaluatePartialResult(std::unordered_map, std::equal_to, std::allocator>>&, std::vector> const&, unsigned long, bool) @ 0x0000000013fa407d 5. /build/src/Interpreters/ActionsDAG.cpp:892: DB::ActionsDAG::updateHeader(DB::Block const&) const @ 0x0000000013fa29a8 6. /build/src/Processors/Transforms/FilterTransform.cpp:47: DB::FilterTransform::transformHeader(DB::Block const&, DB::ActionsDAG const*, String const&, bool) @ 0x0000000016c0e34d 7. /build/src/Processors/QueryPlan/FilterStep.cpp:135: DB::FilterStep::FilterStep(DB::Block const&, DB::ActionsDAG, String, bool) @ 0x0000000016dccc0b 8. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107](DB::Block const&, DB::ActionsDAG&&, String&&, bool&) @ 0x0000000014961e10 9. /build/src/Processors/QueryPlan/Optimizations/filterPushDown.cpp:155: DB::QueryPlanOptimizations::addNewFilterStepOrThrow(DB::QueryPlan::Node*, std::list>&, DB::ActionsDAG, bool, unsigned long, bool) @ 0x0000000016ecd916 10. /build/src/Processors/QueryPlan/Optimizations/filterPushDown.cpp:399: DB::QueryPlanOptimizations::tryPushDownOverJoinStep(DB::QueryPlan::Node*, std::list>&, std::unique_ptr>&) @ 0x0000000016ecc3d9 11. /build/src/Processors/QueryPlan/Optimizations/filterPushDown.cpp:582: DB::QueryPlanOptimizations::tryPushDownFilter(DB::QueryPlan::Node*, std::list>&, DB::QueryPlanOptimizations::Optimization::ExtraSettings const&) @ 0x0000000016eca41a 12. /build/src/Processors/QueryPlan/Optimizations/optimizeTree.cpp:95: DB::QueryPlanOptimizations::optimizeTreeFirstPass(DB::QueryPlanOptimizationSettings const&, DB::QueryPlan::Node&, std::list>&) @ 0x0000000016eac6e0 13. /build/src/Processors/QueryPlan/QueryPlan.cpp:486: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x0000000016e0054d 14. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:275: DB::InterpreterSelectQueryAnalyzer::buildQueryPipeline() @ 0x0000000014974614 15. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:242: DB::InterpreterSelectQueryAnalyzer::execute() @ 0x000000001497439e 16. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88dc9 17. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 18. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 19. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 20. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 21. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 22. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 23. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 24. ? @ 0x00007fbc6213eac3 25. ? @ 0x00007fbc621d0850 2025.07.28 11:54:35.326526 [ 4291 ] {} ExternalDictionariesLoader: Could not load external dictionary 'cc8b1a52-da70-449c-9c23-8d623c5fcc44', next update is scheduled at 2025-07-28 11:55:05: Code: 396. DB::Exception: Limit for result exceeded, max bytes: 1.00 B, current bytes: 36.00 B. (TOO_MANY_ROWS_OR_BYTES), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, char const*&, ReadableSize&&, ReadableSize&&) @ 0x0000000013bd4eeb 4. /build/src/QueryPipeline/SizeLimits.cpp:43: DB::SizeLimits::check(unsigned long, unsigned long, char const*, int, int) const @ 0x0000000013bd48a1 5. /build/src/Processors/Transforms/LimitsCheckingTransform.cpp:45: DB::LimitsCheckingTransform::transform(DB::Chunk&) @ 0x0000000016c1d2fb 6. /build/src/Processors/ISimpleTransform.h:33: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000011a9a453 7. /build/src/Processors/ISimpleTransform.cpp:89: DB::ISimpleTransform::work() @ 0x000000001699fca0 8. /build/src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x00000000169bd00f 9. /build/src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x00000000169b2105 10. /build/src/Processors/Executors/PipelineExecutor.cpp:170: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x00000000169b16a7 11. /build/src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x00000000169c081c 12. /build/src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x00000000169c0978 13. /build/src/Dictionaries/FlatDictionary.cpp:502: DB::FlatDictionary::loadData() @ 0x0000000011b424cb 14. /build/src/Dictionaries/FlatDictionary.cpp:46: DB::FlatDictionary::FlatDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, DB::FlatDictionary::Configuration, std::shared_ptr) @ 0x0000000011b42111 15. /build/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:se190107]> (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) @ 0x0000000011b5d3e2 16. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000012d8a61d 17. /build/src/Interpreters/ExternalDictionariesLoader.cpp:47: DB::ExternalDictionariesLoader::createObject(String const&, Poco::Util::AbstractConfiguration const&, String const&, String const&) const @ 0x00000000148a6f44 18. /build/src/Interpreters/ExternalLoader.cpp:1522: DB::ExternalLoader::LoadingDispatcher::loadSingleObject(String const&, DB::ExternalLoader::ObjectConfig const&, std::shared_ptr) @ 0x00000000148b2ee8 19. /build/src/Interpreters/ExternalLoader.cpp:998: DB::ExternalLoader::LoadingDispatcher::doLoading(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr) @ 0x00000000148b197d 20. /build/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()() @ 0x00000000148b5991 21. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc3d92 22. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fcca080 23. ? @ 0x00007fbc6213eac3 24. ? @ 0x00007fbc621d0850 (version 25.3.6.10636.altinitytest (altinity build)) 2025.07.28 11:54:35.326885 [ 4963 ] {} TCPHandler: Code: 10. DB::Exception: Not found column toUInt128(__table2.id): in block __table2.id UUID UUID(size = 0). (NOT_FOUND_COLUMN_IN_BLOCK), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000a9b78ab 4. /build/src/Interpreters/ActionsDAG.cpp:977: DB::ActionsDAG::evaluatePartialResult(std::unordered_map, std::equal_to, std::allocator>>&, std::vector> const&, unsigned long, bool) @ 0x0000000013fa407d 5. /build/src/Interpreters/ActionsDAG.cpp:892: DB::ActionsDAG::updateHeader(DB::Block const&) const @ 0x0000000013fa29a8 6. /build/src/Processors/Transforms/FilterTransform.cpp:47: DB::FilterTransform::transformHeader(DB::Block const&, DB::ActionsDAG const*, String const&, bool) @ 0x0000000016c0e34d 7. /build/src/Processors/QueryPlan/FilterStep.cpp:135: DB::FilterStep::FilterStep(DB::Block const&, DB::ActionsDAG, String, bool) @ 0x0000000016dccc0b 8. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107](DB::Block const&, DB::ActionsDAG&&, String&&, bool&) @ 0x0000000014961e10 9. /build/src/Processors/QueryPlan/Optimizations/filterPushDown.cpp:155: DB::QueryPlanOptimizations::addNewFilterStepOrThrow(DB::QueryPlan::Node*, std::list>&, DB::ActionsDAG, bool, unsigned long, bool) @ 0x0000000016ecd916 10. /build/src/Processors/QueryPlan/Optimizations/filterPushDown.cpp:399: DB::QueryPlanOptimizations::tryPushDownOverJoinStep(DB::QueryPlan::Node*, std::list>&, std::unique_ptr>&) @ 0x0000000016ecc3d9 11. /build/src/Processors/QueryPlan/Optimizations/filterPushDown.cpp:582: DB::QueryPlanOptimizations::tryPushDownFilter(DB::QueryPlan::Node*, std::list>&, DB::QueryPlanOptimizations::Optimization::ExtraSettings const&) @ 0x0000000016eca41a 12. /build/src/Processors/QueryPlan/Optimizations/optimizeTree.cpp:95: DB::QueryPlanOptimizations::optimizeTreeFirstPass(DB::QueryPlanOptimizationSettings const&, DB::QueryPlan::Node&, std::list>&) @ 0x0000000016eac6e0 13. /build/src/Processors/QueryPlan/QueryPlan.cpp:486: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x0000000016e0054d 14. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:275: DB::InterpreterSelectQueryAnalyzer::buildQueryPipeline() @ 0x0000000014974614 15. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:242: DB::InterpreterSelectQueryAnalyzer::execute() @ 0x000000001497439e 16. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88dc9 17. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 18. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 19. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 20. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 21. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 22. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 23. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 24. ? @ 0x00007fbc6213eac3 25. ? @ 0x00007fbc621d0850 2025.07.28 11:54:35.451856 [ 4963 ] {1b62d869-3da0-4aea-888d-591c43286c4b} executeQuery: Code: 10. DB::Exception: Not found column toUInt128(__table2.id): in block __table2.id UUID UUID(size = 0). (NOT_FOUND_COLUMN_IN_BLOCK) (version 25.3.6.10636.altinitytest (altinity build)) (from [::1]:56458) (comment: 03393_join_bug_77848.sql) (query 9, line 16) (in query: SELECT equals(i.id_uint, 12) FROM BadTable i LEFT JOIN BadJoin c ON i.id_uint = toUInt128(c.id) WHERE equals(i.id_uint, 12);), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000a9b78ab 4. /build/src/Interpreters/ActionsDAG.cpp:977: DB::ActionsDAG::evaluatePartialResult(std::unordered_map, std::equal_to, std::allocator>>&, std::vector> const&, unsigned long, bool) @ 0x0000000013fa407d 5. /build/src/Interpreters/ActionsDAG.cpp:892: DB::ActionsDAG::updateHeader(DB::Block const&) const @ 0x0000000013fa29a8 6. /build/src/Processors/Transforms/FilterTransform.cpp:47: DB::FilterTransform::transformHeader(DB::Block const&, DB::ActionsDAG const*, String const&, bool) @ 0x0000000016c0e34d 7. /build/src/Processors/QueryPlan/FilterStep.cpp:135: DB::FilterStep::FilterStep(DB::Block const&, DB::ActionsDAG, String, bool) @ 0x0000000016dccc0b 8. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107](DB::Block const&, DB::ActionsDAG&&, String&&, bool&) @ 0x0000000014961e10 9. /build/src/Processors/QueryPlan/Optimizations/filterPushDown.cpp:155: DB::QueryPlanOptimizations::addNewFilterStepOrThrow(DB::QueryPlan::Node*, std::list>&, DB::ActionsDAG, bool, unsigned long, bool) @ 0x0000000016ecd916 10. /build/src/Processors/QueryPlan/Optimizations/filterPushDown.cpp:399: DB::QueryPlanOptimizations::tryPushDownOverJoinStep(DB::QueryPlan::Node*, std::list>&, std::unique_ptr>&) @ 0x0000000016ecc3d9 11. /build/src/Processors/QueryPlan/Optimizations/filterPushDown.cpp:582: DB::QueryPlanOptimizations::tryPushDownFilter(DB::QueryPlan::Node*, std::list>&, DB::QueryPlanOptimizations::Optimization::ExtraSettings const&) @ 0x0000000016eca41a 12. /build/src/Processors/QueryPlan/Optimizations/optimizeTree.cpp:95: DB::QueryPlanOptimizations::optimizeTreeFirstPass(DB::QueryPlanOptimizationSettings const&, DB::QueryPlan::Node&, std::list>&) @ 0x0000000016eac6e0 13. /build/src/Processors/QueryPlan/QueryPlan.cpp:486: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x0000000016e0054d 14. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:275: DB::InterpreterSelectQueryAnalyzer::buildQueryPipeline() @ 0x0000000014974614 15. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:242: DB::InterpreterSelectQueryAnalyzer::execute() @ 0x000000001497439e 16. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88dc9 17. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 18. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 19. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 20. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 21. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 22. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 23. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 24. ? @ 0x00007fbc6213eac3 25. ? @ 0x00007fbc621d0850 2025.07.28 11:54:35.458610 [ 4963 ] {} TCPHandler: Code: 10. DB::Exception: Not found column toUInt128(__table2.id): in block __table2.id UUID UUID(size = 0). (NOT_FOUND_COLUMN_IN_BLOCK), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000a9b78ab 4. /build/src/Interpreters/ActionsDAG.cpp:977: DB::ActionsDAG::evaluatePartialResult(std::unordered_map, std::equal_to, std::allocator>>&, std::vector> const&, unsigned long, bool) @ 0x0000000013fa407d 5. /build/src/Interpreters/ActionsDAG.cpp:892: DB::ActionsDAG::updateHeader(DB::Block const&) const @ 0x0000000013fa29a8 6. /build/src/Processors/Transforms/FilterTransform.cpp:47: DB::FilterTransform::transformHeader(DB::Block const&, DB::ActionsDAG const*, String const&, bool) @ 0x0000000016c0e34d 7. /build/src/Processors/QueryPlan/FilterStep.cpp:135: DB::FilterStep::FilterStep(DB::Block const&, DB::ActionsDAG, String, bool) @ 0x0000000016dccc0b 8. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107](DB::Block const&, DB::ActionsDAG&&, String&&, bool&) @ 0x0000000014961e10 9. /build/src/Processors/QueryPlan/Optimizations/filterPushDown.cpp:155: DB::QueryPlanOptimizations::addNewFilterStepOrThrow(DB::QueryPlan::Node*, std::list>&, DB::ActionsDAG, bool, unsigned long, bool) @ 0x0000000016ecd916 10. /build/src/Processors/QueryPlan/Optimizations/filterPushDown.cpp:399: DB::QueryPlanOptimizations::tryPushDownOverJoinStep(DB::QueryPlan::Node*, std::list>&, std::unique_ptr>&) @ 0x0000000016ecc3d9 11. /build/src/Processors/QueryPlan/Optimizations/filterPushDown.cpp:582: DB::QueryPlanOptimizations::tryPushDownFilter(DB::QueryPlan::Node*, std::list>&, DB::QueryPlanOptimizations::Optimization::ExtraSettings const&) @ 0x0000000016eca41a 12. /build/src/Processors/QueryPlan/Optimizations/optimizeTree.cpp:95: DB::QueryPlanOptimizations::optimizeTreeFirstPass(DB::QueryPlanOptimizationSettings const&, DB::QueryPlan::Node&, std::list>&) @ 0x0000000016eac6e0 13. /build/src/Processors/QueryPlan/QueryPlan.cpp:486: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x0000000016e0054d 14. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:275: DB::InterpreterSelectQueryAnalyzer::buildQueryPipeline() @ 0x0000000014974614 15. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:242: DB::InterpreterSelectQueryAnalyzer::execute() @ 0x000000001497439e 16. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88dc9 17. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 18. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 19. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 20. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 21. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 22. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 23. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 24. ? @ 0x00007fbc6213eac3 25. ? @ 0x00007fbc621d0850 2025.07.28 11:54:35.697133 [ 17252 ] {1ed18a29-f81c-4680-9f39-213c181b8db7} executeQuery: Code: 219. DB::Exception: New table appeared in database being dropped or detached. Try again. (DATABASE_NOT_EMPTY) (version 25.3.6.10636.altinitytest (altinity build)) (from [::1]:60228) (comment: 03393_join_bug_77848.sql) (in query: DROP DATABASE IF EXISTS test_hyn8bxqf SYNC ), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000000a074fcb 4. /build/src/Interpreters/DatabaseCatalog.cpp:608: DB::DatabaseCatalog::detachDatabase(std::shared_ptr, String const&, bool, bool) @ 0x00000000144f41b9 5. /build/src/Interpreters/InterpreterDropQuery.cpp:482: DB::InterpreterDropQuery::executeToDatabaseImpl(DB::ASTDropQuery const&, std::shared_ptr&, std::vector, DB::UUIDTag>, std::allocator, DB::UUIDTag>>>&) @ 0x00000000149179be 6. /build/src/Interpreters/InterpreterDropQuery.cpp:363: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x0000000014913988 7. /build/src/Interpreters/InterpreterDropQuery.cpp:99: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000014913142 8. /build/src/Interpreters/InterpreterDropQuery.cpp:72: DB::InterpreterDropQuery::execute() @ 0x0000000014912b65 9. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88dc9 10. /build/src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x0000000014c8ca7b 11. /build/src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000001686da12 12. /build/src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x0000000016870807 13. /build/src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x0000000016907e99 14. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 15. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 16. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 17. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 18. ? @ 0x00007fbc6213eac3 19. ? @ 0x00007fbc621d0850 2025.07.28 11:54:35.698881 [ 17252 ] {1ed18a29-f81c-4680-9f39-213c181b8db7} 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. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000000a074fcb 4. /build/src/Interpreters/DatabaseCatalog.cpp:608: DB::DatabaseCatalog::detachDatabase(std::shared_ptr, String const&, bool, bool) @ 0x00000000144f41b9 5. /build/src/Interpreters/InterpreterDropQuery.cpp:482: DB::InterpreterDropQuery::executeToDatabaseImpl(DB::ASTDropQuery const&, std::shared_ptr&, std::vector, DB::UUIDTag>, std::allocator, DB::UUIDTag>>>&) @ 0x00000000149179be 6. /build/src/Interpreters/InterpreterDropQuery.cpp:363: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x0000000014913988 7. /build/src/Interpreters/InterpreterDropQuery.cpp:99: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000014913142 8. /build/src/Interpreters/InterpreterDropQuery.cpp:72: DB::InterpreterDropQuery::execute() @ 0x0000000014912b65 9. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88dc9 10. /build/src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x0000000014c8ca7b 11. /build/src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000001686da12 12. /build/src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x0000000016870807 13. /build/src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x0000000016907e99 14. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 15. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 16. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 17. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 18. ? @ 0x00007fbc6213eac3 19. ? @ 0x00007fbc621d0850 (version 25.3.6.10636.altinitytest (altinity build)) 2025.07.28 11:54:35.754282 [ 3287 ] {2c7f6fde-183a-4b30-823d-eadc6be99ea2} executeQuery: Code: 219. DB::Exception: New table appeared in database being dropped or detached. Try again. (DATABASE_NOT_EMPTY) (version 25.3.6.10636.altinitytest (altinity build)) (from [::1]:60242) (comment: 03393_join_bug_77848.sql) (in query: DROP DATABASE IF EXISTS test_hyn8bxqf SYNC ), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000000a074fcb 4. /build/src/Interpreters/DatabaseCatalog.cpp:608: DB::DatabaseCatalog::detachDatabase(std::shared_ptr, String const&, bool, bool) @ 0x00000000144f41b9 5. /build/src/Interpreters/InterpreterDropQuery.cpp:482: DB::InterpreterDropQuery::executeToDatabaseImpl(DB::ASTDropQuery const&, std::shared_ptr&, std::vector, DB::UUIDTag>, std::allocator, DB::UUIDTag>>>&) @ 0x00000000149179be 6. /build/src/Interpreters/InterpreterDropQuery.cpp:363: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x0000000014913988 7. /build/src/Interpreters/InterpreterDropQuery.cpp:99: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000014913142 8. /build/src/Interpreters/InterpreterDropQuery.cpp:72: DB::InterpreterDropQuery::execute() @ 0x0000000014912b65 9. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88dc9 10. /build/src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x0000000014c8ca7b 11. /build/src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000001686da12 12. /build/src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x0000000016870807 13. /build/src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x0000000016907e99 14. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 15. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 16. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 17. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 18. ? @ 0x00007fbc6213eac3 19. ? @ 0x00007fbc621d0850 2025.07.28 11:54:35.758442 [ 3287 ] {2c7f6fde-183a-4b30-823d-eadc6be99ea2} 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. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000000a074fcb 4. /build/src/Interpreters/DatabaseCatalog.cpp:608: DB::DatabaseCatalog::detachDatabase(std::shared_ptr, String const&, bool, bool) @ 0x00000000144f41b9 5. /build/src/Interpreters/InterpreterDropQuery.cpp:482: DB::InterpreterDropQuery::executeToDatabaseImpl(DB::ASTDropQuery const&, std::shared_ptr&, std::vector, DB::UUIDTag>, std::allocator, DB::UUIDTag>>>&) @ 0x00000000149179be 6. /build/src/Interpreters/InterpreterDropQuery.cpp:363: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x0000000014913988 7. /build/src/Interpreters/InterpreterDropQuery.cpp:99: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000014913142 8. /build/src/Interpreters/InterpreterDropQuery.cpp:72: DB::InterpreterDropQuery::execute() @ 0x0000000014912b65 9. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88dc9 10. /build/src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x0000000014c8ca7b 11. /build/src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000001686da12 12. /build/src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x0000000016870807 13. /build/src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x0000000016907e99 14. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 15. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 16. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 17. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 18. ? @ 0x00007fbc6213eac3 19. ? @ 0x00007fbc621d0850 (version 25.3.6.10636.altinitytest (altinity build)) 2025.07.28 11:54:35.859554 [ 17252 ] {c068dcba-fabf-4bd1-b1ae-018db5eed95a} executeQuery: Code: 219. DB::Exception: New table appeared in database being dropped or detached. Try again. (DATABASE_NOT_EMPTY) (version 25.3.6.10636.altinitytest (altinity build)) (from [::1]:60256) (comment: 03393_join_bug_77848.sql) (in query: DROP DATABASE IF EXISTS test_hyn8bxqf SYNC ), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000000a074fcb 4. /build/src/Interpreters/DatabaseCatalog.cpp:608: DB::DatabaseCatalog::detachDatabase(std::shared_ptr, String const&, bool, bool) @ 0x00000000144f41b9 5. /build/src/Interpreters/InterpreterDropQuery.cpp:482: DB::InterpreterDropQuery::executeToDatabaseImpl(DB::ASTDropQuery const&, std::shared_ptr&, std::vector, DB::UUIDTag>, std::allocator, DB::UUIDTag>>>&) @ 0x00000000149179be 6. /build/src/Interpreters/InterpreterDropQuery.cpp:363: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x0000000014913988 7. /build/src/Interpreters/InterpreterDropQuery.cpp:99: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000014913142 8. /build/src/Interpreters/InterpreterDropQuery.cpp:72: DB::InterpreterDropQuery::execute() @ 0x0000000014912b65 9. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88dc9 10. /build/src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x0000000014c8ca7b 11. /build/src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000001686da12 12. /build/src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x0000000016870807 13. /build/src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x0000000016907e99 14. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 15. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 16. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 17. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 18. ? @ 0x00007fbc6213eac3 19. ? @ 0x00007fbc621d0850 2025.07.28 11:54:35.865926 [ 17252 ] {c068dcba-fabf-4bd1-b1ae-018db5eed95a} 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. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000000a074fcb 4. /build/src/Interpreters/DatabaseCatalog.cpp:608: DB::DatabaseCatalog::detachDatabase(std::shared_ptr, String const&, bool, bool) @ 0x00000000144f41b9 5. /build/src/Interpreters/InterpreterDropQuery.cpp:482: DB::InterpreterDropQuery::executeToDatabaseImpl(DB::ASTDropQuery const&, std::shared_ptr&, std::vector, DB::UUIDTag>, std::allocator, DB::UUIDTag>>>&) @ 0x00000000149179be 6. /build/src/Interpreters/InterpreterDropQuery.cpp:363: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x0000000014913988 7. /build/src/Interpreters/InterpreterDropQuery.cpp:99: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000014913142 8. /build/src/Interpreters/InterpreterDropQuery.cpp:72: DB::InterpreterDropQuery::execute() @ 0x0000000014912b65 9. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88dc9 10. /build/src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x0000000014c8ca7b 11. /build/src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000001686da12 12. /build/src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x0000000016870807 13. /build/src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x0000000016907e99 14. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 15. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 16. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 17. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 18. ? @ 0x00007fbc6213eac3 19. ? @ 0x00007fbc621d0850 (version 25.3.6.10636.altinitytest (altinity build)) 2025.07.28 11:54:36.050283 [ 3976 ] {} test_13.rmt2 (7f9b740d-015c-470e-8cc6-8ba33be0dc63): auto DB::StorageReplicatedMergeTree::processQueueEntry(ReplicatedMergeTreeQueue::SelectedEntryPtr)::(anonymous class)::operator()(LogEntryPtr &) const: Code: 86. DB::HTTPException: Received error from remote server http://146b4357c08d:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Ftest%2F01165%2Ftest_13%2Frmt%2Freplicas%2F1&part=20250728_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.6.10636.altinitytest (altinity build)) '. (RECEIVED_ERROR_FROM_REMOTE_IO_SERVER), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.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 const&, int&&, String const&, unsigned long&&, String const&) @ 0x000000000feda8d9 4. /build/src/IO/HTTPCommon.cpp:104: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x000000000feda6e2 5. /build/src/IO/HTTPCommon.cpp:93: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x000000000feda537 6. /build/src/IO/ReadWriteBufferFromHTTP.cpp:277: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x000000001184a4c4 7. /build/src/IO/ReadWriteBufferFromHTTP.cpp:285: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x000000001184a615 8. /build/src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x000000001184ae59 9. /build/src/IO/ReadWriteBufferFromHTTP.cpp:472: void std::__function::__policy_invoker::__call_impl[abi:se190107]>(std::__function::__policy_storage const*) @ 0x000000001184cedd 10. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001184858b 11. /build/src/IO/ReadWriteBufferFromHTTP.cpp:465: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x000000001184bf0b 12. /build/src/IO/ReadBuffer.h:60: DB::ReadBuffer::next() @ 0x000000000a148c7b 13. /build/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) @ 0x0000000011849fb2 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]>&)>&, 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&) @ 0x0000000011841980 15. /build/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) @ 0x000000001621208e 16. /build/src/Storages/StorageReplicatedMergeTree.cpp:5228: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl[abi:se190107] const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000015f9a5fe 17. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000015ed8bfd 18. /build/src/Storages/StorageReplicatedMergeTree.cpp:2514: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x0000000015ec9aab 19. /build/src/Storages/StorageReplicatedMergeTree.cpp:2349: DB::StorageReplicatedMergeTree::executeLogEntry(DB::ReplicatedMergeTreeLogEntry&) @ 0x0000000015eba91b 20. /build/src/Storages/StorageReplicatedMergeTree.cpp:3876: bool std::__function::__policy_invoker&)>::__call_impl[abi:se190107])::$_1, bool (std::shared_ptr&)>>(std::__function::__policy_storage const*, std::shared_ptr&) @ 0x0000000015f9837e 21. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000165d6fc3 22. /build/src/Storages/StorageReplicatedMergeTree.cpp:3872: DB::StorageReplicatedMergeTree::processQueueEntry(std::shared_ptr) @ 0x0000000015efc18a 23. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001624c1b2 24. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000162f9c70 25. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x00000000162fa55a 26. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc6653 27. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000000fccc4c3 28. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc3d92 29. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fcca080 30. ? @ 0x00007fbc6213eac3 31. ? @ 0x00007fbc621d0850 (version 25.3.6.10636.altinitytest (altinity build)) 2025.07.28 11:54:36.668139 [ 3971 ] {} test_13.rmt2 (7f9b740d-015c-470e-8cc6-8ba33be0dc63): auto DB::StorageReplicatedMergeTree::processQueueEntry(ReplicatedMergeTreeQueue::SelectedEntryPtr)::(anonymous class)::operator()(LogEntryPtr &) const: Code: 86. DB::HTTPException: Received error from remote server http://146b4357c08d:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Ftest%2F01165%2Ftest_13%2Frmt%2Freplicas%2F1&part=20250728_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.6.10636.altinitytest (altinity build)) '. (RECEIVED_ERROR_FROM_REMOTE_IO_SERVER), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.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 const&, int&&, String const&, unsigned long&&, String const&) @ 0x000000000feda8d9 4. /build/src/IO/HTTPCommon.cpp:104: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x000000000feda6e2 5. /build/src/IO/HTTPCommon.cpp:93: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x000000000feda537 6. /build/src/IO/ReadWriteBufferFromHTTP.cpp:277: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x000000001184a4c4 7. /build/src/IO/ReadWriteBufferFromHTTP.cpp:285: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x000000001184a615 8. /build/src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x000000001184ae59 9. /build/src/IO/ReadWriteBufferFromHTTP.cpp:472: void std::__function::__policy_invoker::__call_impl[abi:se190107]>(std::__function::__policy_storage const*) @ 0x000000001184cedd 10. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001184858b 11. /build/src/IO/ReadWriteBufferFromHTTP.cpp:465: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x000000001184bf0b 12. /build/src/IO/ReadBuffer.h:60: DB::ReadBuffer::next() @ 0x000000000a148c7b 13. /build/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) @ 0x0000000011849fb2 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]>&)>&, 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&) @ 0x0000000011841980 15. /build/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) @ 0x000000001621208e 16. /build/src/Storages/StorageReplicatedMergeTree.cpp:5228: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl[abi:se190107] const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000015f9a5fe 17. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000015ed8bfd 18. /build/src/Storages/StorageReplicatedMergeTree.cpp:2514: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x0000000015ec9aab 19. /build/src/Storages/StorageReplicatedMergeTree.cpp:2349: DB::StorageReplicatedMergeTree::executeLogEntry(DB::ReplicatedMergeTreeLogEntry&) @ 0x0000000015eba91b 20. /build/src/Storages/StorageReplicatedMergeTree.cpp:3876: bool std::__function::__policy_invoker&)>::__call_impl[abi:se190107])::$_1, bool (std::shared_ptr&)>>(std::__function::__policy_storage const*, std::shared_ptr&) @ 0x0000000015f9837e 21. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000165d6fc3 22. /build/src/Storages/StorageReplicatedMergeTree.cpp:3872: DB::StorageReplicatedMergeTree::processQueueEntry(std::shared_ptr) @ 0x0000000015efc18a 23. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001624c1b2 24. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000162f9c70 25. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x00000000162fa55a 26. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc6653 27. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000000fccc4c3 28. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc3d92 29. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fcca080 30. ? @ 0x00007fbc6213eac3 31. ? @ 0x00007fbc621d0850 (version 25.3.6.10636.altinitytest (altinity build)) 2025.07.28 11:54:37.620093 [ 3970 ] {} test_13.rmt2 (7f9b740d-015c-470e-8cc6-8ba33be0dc63): auto DB::StorageReplicatedMergeTree::processQueueEntry(ReplicatedMergeTreeQueue::SelectedEntryPtr)::(anonymous class)::operator()(LogEntryPtr &) const: Code: 86. DB::HTTPException: Received error from remote server http://146b4357c08d:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Ftest%2F01165%2Ftest_13%2Frmt%2Freplicas%2F1&part=20250728_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.6.10636.altinitytest (altinity build)) '. (RECEIVED_ERROR_FROM_REMOTE_IO_SERVER), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.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 const&, int&&, String const&, unsigned long&&, String const&) @ 0x000000000feda8d9 4. /build/src/IO/HTTPCommon.cpp:104: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x000000000feda6e2 5. /build/src/IO/HTTPCommon.cpp:93: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x000000000feda537 6. /build/src/IO/ReadWriteBufferFromHTTP.cpp:277: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x000000001184a4c4 7. /build/src/IO/ReadWriteBufferFromHTTP.cpp:285: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x000000001184a615 8. /build/src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x000000001184ae59 9. /build/src/IO/ReadWriteBufferFromHTTP.cpp:472: void std::__function::__policy_invoker::__call_impl[abi:se190107]>(std::__function::__policy_storage const*) @ 0x000000001184cedd 10. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001184858b 11. /build/src/IO/ReadWriteBufferFromHTTP.cpp:465: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x000000001184bf0b 12. /build/src/IO/ReadBuffer.h:60: DB::ReadBuffer::next() @ 0x000000000a148c7b 13. /build/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) @ 0x0000000011849fb2 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]>&)>&, 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&) @ 0x0000000011841980 15. /build/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) @ 0x000000001621208e 16. /build/src/Storages/StorageReplicatedMergeTree.cpp:5228: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl[abi:se190107] const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000015f9a5fe 17. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000015ed8bfd 18. /build/src/Storages/StorageReplicatedMergeTree.cpp:2514: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x0000000015ec9aab 19. /build/src/Storages/StorageReplicatedMergeTree.cpp:2349: DB::StorageReplicatedMergeTree::executeLogEntry(DB::ReplicatedMergeTreeLogEntry&) @ 0x0000000015eba91b 20. /build/src/Storages/StorageReplicatedMergeTree.cpp:3876: bool std::__function::__policy_invoker&)>::__call_impl[abi:se190107])::$_1, bool (std::shared_ptr&)>>(std::__function::__policy_storage const*, std::shared_ptr&) @ 0x0000000015f9837e 21. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000165d6fc3 22. /build/src/Storages/StorageReplicatedMergeTree.cpp:3872: DB::StorageReplicatedMergeTree::processQueueEntry(std::shared_ptr) @ 0x0000000015efc18a 23. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001624c1b2 24. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000162f9c70 25. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x00000000162fa55a 26. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc6653 27. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000000fccc4c3 28. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc3d92 29. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fcca080 30. ? @ 0x00007fbc6213eac3 31. ? @ 0x00007fbc621d0850 (version 25.3.6.10636.altinitytest (altinity build)) 2025.07.28 11:54:38.412268 [ 3972 ] {} test_13.rmt2 (7f9b740d-015c-470e-8cc6-8ba33be0dc63): auto DB::StorageReplicatedMergeTree::processQueueEntry(ReplicatedMergeTreeQueue::SelectedEntryPtr)::(anonymous class)::operator()(LogEntryPtr &) const: Code: 86. DB::HTTPException: Received error from remote server http://146b4357c08d:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Ftest%2F01165%2Ftest_13%2Frmt%2Freplicas%2F1&part=20250728_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.6.10636.altinitytest (altinity build)) '. (RECEIVED_ERROR_FROM_REMOTE_IO_SERVER), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.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 const&, int&&, String const&, unsigned long&&, String const&) @ 0x000000000feda8d9 4. /build/src/IO/HTTPCommon.cpp:104: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x000000000feda6e2 5. /build/src/IO/HTTPCommon.cpp:93: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x000000000feda537 6. /build/src/IO/ReadWriteBufferFromHTTP.cpp:277: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x000000001184a4c4 7. /build/src/IO/ReadWriteBufferFromHTTP.cpp:285: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x000000001184a615 8. /build/src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x000000001184ae59 9. /build/src/IO/ReadWriteBufferFromHTTP.cpp:472: void std::__function::__policy_invoker::__call_impl[abi:se190107]>(std::__function::__policy_storage const*) @ 0x000000001184cedd 10. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001184858b 11. /build/src/IO/ReadWriteBufferFromHTTP.cpp:465: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x000000001184bf0b 12. /build/src/IO/ReadBuffer.h:60: DB::ReadBuffer::next() @ 0x000000000a148c7b 13. /build/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) @ 0x0000000011849fb2 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]>&)>&, 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&) @ 0x0000000011841980 15. /build/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) @ 0x000000001621208e 16. /build/src/Storages/StorageReplicatedMergeTree.cpp:5228: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl[abi:se190107] const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000015f9a5fe 17. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000015ed8bfd 18. /build/src/Storages/StorageReplicatedMergeTree.cpp:2514: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x0000000015ec9aab 19. /build/src/Storages/StorageReplicatedMergeTree.cpp:2349: DB::StorageReplicatedMergeTree::executeLogEntry(DB::ReplicatedMergeTreeLogEntry&) @ 0x0000000015eba91b 20. /build/src/Storages/StorageReplicatedMergeTree.cpp:3876: bool std::__function::__policy_invoker&)>::__call_impl[abi:se190107])::$_1, bool (std::shared_ptr&)>>(std::__function::__policy_storage const*, std::shared_ptr&) @ 0x0000000015f9837e 21. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000165d6fc3 22. /build/src/Storages/StorageReplicatedMergeTree.cpp:3872: DB::StorageReplicatedMergeTree::processQueueEntry(std::shared_ptr) @ 0x0000000015efc18a 23. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001624c1b2 24. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000162f9c70 25. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x00000000162fa55a 26. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc6653 27. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000000fccc4c3 28. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc3d92 29. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fcca080 30. ? @ 0x00007fbc6213eac3 31. ? @ 0x00007fbc621d0850 (version 25.3.6.10636.altinitytest (altinity build)) 2025.07.28 11:54:38.417745 [ 17252 ] {aeb04cd9-feb6-48f7-b3ea-a75ffcf8fb34} executeQuery: Code: 36. DB::Exception: Value of width must not be NaN and Inf: In scope SELECT greatCircleAngle(1048575, 257, -9223372036854775808, 1048576) - NULL, bar(7, -inf, 1024). (BAD_ARGUMENTS) (version 25.3.6.10636.altinitytest (altinity build)) (from [::1]:56602) (comment: 01774_bar_with_illegal_value.sql) (query 1, line 1) (in query: SELECT greatCircleAngle(1048575, 257, -9223372036854775808, 1048576) - NULL, bar(7, -inf, 1024);), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000000a074fcb 4. /build/src/Functions/bar.cpp:120: DB::(anonymous namespace)::FunctionBar::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000aad9315 5. /build/src/Functions/IFunction.h:437: DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000a069f2a 6. /build/src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000012d9965a 7. /build/src/Functions/IFunction.cpp:351: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d93b02 8. /build/src/Functions/IFunction.cpp:177: DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d93698 9. /build/src/Functions/IFunction.cpp:343: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d93aad 10. /build/src/Functions/IFunction.cpp:420: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d95059 11. /build/src/Functions/IFunction.cpp:498: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d95c72 12. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3567: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000014034494 13. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3838: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000014019a9e 14. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3980: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000014018e31 15. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:4304: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000014042fa7 16. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5605: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000014013749 17. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000140127f9 18. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000014011fce 19. /build/src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000001406ce8a 20. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000014973b42 21. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000001497268d 22. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000014974d24 23. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001492924b 24. /build/src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88641 25. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 26. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 27. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 28. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 29. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 30. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 31. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 2025.07.28 11:54:38.421086 [ 17252 ] {} TCPHandler: Code: 36. DB::Exception: Value of width must not be NaN and Inf: In scope SELECT greatCircleAngle(1048575, 257, -9223372036854775808, 1048576) - NULL, bar(7, -inf, 1024). (BAD_ARGUMENTS), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000000a074fcb 4. /build/src/Functions/bar.cpp:120: DB::(anonymous namespace)::FunctionBar::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000aad9315 5. /build/src/Functions/IFunction.h:437: DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000a069f2a 6. /build/src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000012d9965a 7. /build/src/Functions/IFunction.cpp:351: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d93b02 8. /build/src/Functions/IFunction.cpp:177: DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d93698 9. /build/src/Functions/IFunction.cpp:343: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d93aad 10. /build/src/Functions/IFunction.cpp:420: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d95059 11. /build/src/Functions/IFunction.cpp:498: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d95c72 12. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3567: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000014034494 13. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3838: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000014019a9e 14. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3980: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000014018e31 15. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:4304: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000014042fa7 16. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5605: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000014013749 17. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000140127f9 18. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000014011fce 19. /build/src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000001406ce8a 20. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000014973b42 21. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000001497268d 22. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000014974d24 23. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001492924b 24. /build/src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88641 25. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 26. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 27. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 28. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 29. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 30. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 31. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 2025.07.28 11:54:38.548313 [ 3969 ] {} test_13.rmt2 (7f9b740d-015c-470e-8cc6-8ba33be0dc63): auto DB::StorageReplicatedMergeTree::processQueueEntry(ReplicatedMergeTreeQueue::SelectedEntryPtr)::(anonymous class)::operator()(LogEntryPtr &) const: Code: 86. DB::HTTPException: Received error from remote server http://146b4357c08d:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Ftest%2F01165%2Ftest_13%2Frmt%2Freplicas%2F1&part=20250728_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.6.10636.altinitytest (altinity build)) '. (RECEIVED_ERROR_FROM_REMOTE_IO_SERVER), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.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 const&, int&&, String const&, unsigned long&&, String const&) @ 0x000000000feda8d9 4. /build/src/IO/HTTPCommon.cpp:104: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x000000000feda6e2 5. /build/src/IO/HTTPCommon.cpp:93: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x000000000feda537 6. /build/src/IO/ReadWriteBufferFromHTTP.cpp:277: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x000000001184a4c4 7. /build/src/IO/ReadWriteBufferFromHTTP.cpp:285: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x000000001184a615 8. /build/src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x000000001184ae59 9. /build/src/IO/ReadWriteBufferFromHTTP.cpp:472: void std::__function::__policy_invoker::__call_impl[abi:se190107]>(std::__function::__policy_storage const*) @ 0x000000001184cedd 10. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001184858b 11. /build/src/IO/ReadWriteBufferFromHTTP.cpp:465: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x000000001184bf0b 12. /build/src/IO/ReadBuffer.h:60: DB::ReadBuffer::next() @ 0x000000000a148c7b 13. /build/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) @ 0x0000000011849fb2 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]>&)>&, 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&) @ 0x0000000011841980 15. /build/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) @ 0x000000001621208e 16. /build/src/Storages/StorageReplicatedMergeTree.cpp:5228: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl[abi:se190107] const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000015f9a5fe 17. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000015ed8bfd 18. /build/src/Storages/StorageReplicatedMergeTree.cpp:2514: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x0000000015ec9aab 19. /build/src/Storages/StorageReplicatedMergeTree.cpp:2349: DB::StorageReplicatedMergeTree::executeLogEntry(DB::ReplicatedMergeTreeLogEntry&) @ 0x0000000015eba91b 20. /build/src/Storages/StorageReplicatedMergeTree.cpp:3876: bool std::__function::__policy_invoker&)>::__call_impl[abi:se190107])::$_1, bool (std::shared_ptr&)>>(std::__function::__policy_storage const*, std::shared_ptr&) @ 0x0000000015f9837e 21. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000165d6fc3 22. /build/src/Storages/StorageReplicatedMergeTree.cpp:3872: DB::StorageReplicatedMergeTree::processQueueEntry(std::shared_ptr) @ 0x0000000015efc18a 23. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001624c1b2 24. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000162f9c70 25. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x00000000162fa55a 26. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc6653 27. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000000fccc4c3 28. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc3d92 29. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fcca080 30. ? @ 0x00007fbc6213eac3 31. ? @ 0x00007fbc621d0850 (version 25.3.6.10636.altinitytest (altinity build)) 2025.07.28 11:54:38.912588 [ 3965 ] {} test_13.rmt2 (7f9b740d-015c-470e-8cc6-8ba33be0dc63): auto DB::StorageReplicatedMergeTree::processQueueEntry(ReplicatedMergeTreeQueue::SelectedEntryPtr)::(anonymous class)::operator()(LogEntryPtr &) const: Code: 86. DB::HTTPException: Received error from remote server http://146b4357c08d:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Ftest%2F01165%2Ftest_13%2Frmt%2Freplicas%2F1&part=20250728_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.6.10636.altinitytest (altinity build)) '. (RECEIVED_ERROR_FROM_REMOTE_IO_SERVER), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.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 const&, int&&, String const&, unsigned long&&, String const&) @ 0x000000000feda8d9 4. /build/src/IO/HTTPCommon.cpp:104: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x000000000feda6e2 5. /build/src/IO/HTTPCommon.cpp:93: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x000000000feda537 6. /build/src/IO/ReadWriteBufferFromHTTP.cpp:277: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x000000001184a4c4 7. /build/src/IO/ReadWriteBufferFromHTTP.cpp:285: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x000000001184a615 8. /build/src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x000000001184ae59 9. /build/src/IO/ReadWriteBufferFromHTTP.cpp:472: void std::__function::__policy_invoker::__call_impl[abi:se190107]>(std::__function::__policy_storage const*) @ 0x000000001184cedd 10. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001184858b 11. /build/src/IO/ReadWriteBufferFromHTTP.cpp:465: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x000000001184bf0b 12. /build/src/IO/ReadBuffer.h:60: DB::ReadBuffer::next() @ 0x000000000a148c7b 13. /build/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) @ 0x0000000011849fb2 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]>&)>&, 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&) @ 0x0000000011841980 15. /build/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) @ 0x000000001621208e 16. /build/src/Storages/StorageReplicatedMergeTree.cpp:5228: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl[abi:se190107] const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000015f9a5fe 17. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000015ed8bfd 18. /build/src/Storages/StorageReplicatedMergeTree.cpp:2514: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x0000000015ec9aab 19. /build/src/Storages/StorageReplicatedMergeTree.cpp:2349: DB::StorageReplicatedMergeTree::executeLogEntry(DB::ReplicatedMergeTreeLogEntry&) @ 0x0000000015eba91b 20. /build/src/Storages/StorageReplicatedMergeTree.cpp:3876: bool std::__function::__policy_invoker&)>::__call_impl[abi:se190107])::$_1, bool (std::shared_ptr&)>>(std::__function::__policy_storage const*, std::shared_ptr&) @ 0x0000000015f9837e 21. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000165d6fc3 22. /build/src/Storages/StorageReplicatedMergeTree.cpp:3872: DB::StorageReplicatedMergeTree::processQueueEntry(std::shared_ptr) @ 0x0000000015efc18a 23. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001624c1b2 24. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000162f9c70 25. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x00000000162fa55a 26. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc6653 27. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000000fccc4c3 28. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc3d92 29. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fcca080 30. ? @ 0x00007fbc6213eac3 31. ? @ 0x00007fbc621d0850 (version 25.3.6.10636.altinitytest (altinity build)) 2025.07.28 11:54:39.145619 [ 17270 ] {adbfec8b-702c-4d33-9b39-c05d3844cc28} executeQuery: Code: 48. DB::Exception: Truncate is not supported by storage Merge. (NOT_IMPLEMENTED) (version 25.3.6.10636.altinitytest (altinity build)) (from [::1]:56548) (comment: 01298_alter_merge.sql) (query 22, line 35) (in query: drop table merge;), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x000000000a06b56b 4. /build/src/Storages/IStorage.cpp:171: DB::IStorage::truncate(std::shared_ptr const&, std::shared_ptr const&, std::shared_ptr, DB::TableExclusiveLockHolder&) @ 0x0000000015d1ec7a 5. /build/src/Interpreters/InterpreterDropQuery.cpp:282: DB::InterpreterDropQuery::executeToTableImpl(std::shared_ptr const&, DB::ASTDropQuery&, std::shared_ptr&, StrongTypedef, DB::UUIDTag>&) @ 0x0000000014915304 6. /build/src/Interpreters/InterpreterDropQuery.cpp:118: DB::InterpreterDropQuery::executeToTable(DB::ASTDropQuery&) @ 0x00000000149137b4 7. /build/src/Interpreters/InterpreterDropQuery.cpp:91: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000014912f07 8. /build/src/Interpreters/InterpreterDropQuery.cpp:72: DB::InterpreterDropQuery::execute() @ 0x0000000014912b65 9. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88dc9 10. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 11. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 12. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 13. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 14. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 16. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 17. ? @ 0x00007fbc6213eac3 18. ? @ 0x00007fbc621d0850 2025.07.28 11:54:39.159397 [ 17270 ] {} 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. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x000000000a06b56b 4. /build/src/Storages/IStorage.cpp:171: DB::IStorage::truncate(std::shared_ptr const&, std::shared_ptr const&, std::shared_ptr, DB::TableExclusiveLockHolder&) @ 0x0000000015d1ec7a 5. /build/src/Interpreters/InterpreterDropQuery.cpp:282: DB::InterpreterDropQuery::executeToTableImpl(std::shared_ptr const&, DB::ASTDropQuery&, std::shared_ptr&, StrongTypedef, DB::UUIDTag>&) @ 0x0000000014915304 6. /build/src/Interpreters/InterpreterDropQuery.cpp:118: DB::InterpreterDropQuery::executeToTable(DB::ASTDropQuery&) @ 0x00000000149137b4 7. /build/src/Interpreters/InterpreterDropQuery.cpp:91: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000014912f07 8. /build/src/Interpreters/InterpreterDropQuery.cpp:72: DB::InterpreterDropQuery::execute() @ 0x0000000014912b65 9. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88dc9 10. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 11. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 12. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 13. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 14. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 16. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 17. ? @ 0x00007fbc6213eac3 18. ? @ 0x00007fbc621d0850 2025.07.28 11:54:39.543289 [ 3960 ] {} test_13.rmt2 (7f9b740d-015c-470e-8cc6-8ba33be0dc63): auto DB::StorageReplicatedMergeTree::processQueueEntry(ReplicatedMergeTreeQueue::SelectedEntryPtr)::(anonymous class)::operator()(LogEntryPtr &) const: Code: 86. DB::HTTPException: Received error from remote server http://146b4357c08d:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Ftest%2F01165%2Ftest_13%2Frmt%2Freplicas%2F1&part=20250728_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.6.10636.altinitytest (altinity build)) '. (RECEIVED_ERROR_FROM_REMOTE_IO_SERVER), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.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 const&, int&&, String const&, unsigned long&&, String const&) @ 0x000000000feda8d9 4. /build/src/IO/HTTPCommon.cpp:104: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x000000000feda6e2 5. /build/src/IO/HTTPCommon.cpp:93: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x000000000feda537 6. /build/src/IO/ReadWriteBufferFromHTTP.cpp:277: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x000000001184a4c4 7. /build/src/IO/ReadWriteBufferFromHTTP.cpp:285: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x000000001184a615 8. /build/src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x000000001184ae59 9. /build/src/IO/ReadWriteBufferFromHTTP.cpp:472: void std::__function::__policy_invoker::__call_impl[abi:se190107]>(std::__function::__policy_storage const*) @ 0x000000001184cedd 10. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001184858b 11. /build/src/IO/ReadWriteBufferFromHTTP.cpp:465: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x000000001184bf0b 12. /build/src/IO/ReadBuffer.h:60: DB::ReadBuffer::next() @ 0x000000000a148c7b 13. /build/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) @ 0x0000000011849fb2 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]>&)>&, 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&) @ 0x0000000011841980 15. /build/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) @ 0x000000001621208e 16. /build/src/Storages/StorageReplicatedMergeTree.cpp:5228: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl[abi:se190107] const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000015f9a5fe 17. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000015ed8bfd 18. /build/src/Storages/StorageReplicatedMergeTree.cpp:2514: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x0000000015ec9aab 19. /build/src/Storages/StorageReplicatedMergeTree.cpp:2349: DB::StorageReplicatedMergeTree::executeLogEntry(DB::ReplicatedMergeTreeLogEntry&) @ 0x0000000015eba91b 20. /build/src/Storages/StorageReplicatedMergeTree.cpp:3876: bool std::__function::__policy_invoker&)>::__call_impl[abi:se190107])::$_1, bool (std::shared_ptr&)>>(std::__function::__policy_storage const*, std::shared_ptr&) @ 0x0000000015f9837e 21. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000165d6fc3 22. /build/src/Storages/StorageReplicatedMergeTree.cpp:3872: DB::StorageReplicatedMergeTree::processQueueEntry(std::shared_ptr) @ 0x0000000015efc18a 23. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001624c1b2 24. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000162f9c70 25. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x00000000162fa55a 26. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc6653 27. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000000fccc4c3 28. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc3d92 29. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fcca080 30. ? @ 0x00007fbc6213eac3 31. ? @ 0x00007fbc621d0850 (version 25.3.6.10636.altinitytest (altinity build)) 2025.07.28 11:54:39.747460 [ 5825 ] {d86a23c5-2729-42c5-9694-41e0e640a8ae} executeQuery: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=835, jobs=801). (CANNOT_SCHEDULE_TASK) (version 25.3.6.10636.altinitytest (altinity build)) (from [::1]:56554) (comment: 02015_division_by_nullable.sql) (query 25, line 37) (in query: SELECT intDiv(1, CAST(NULL, 'Nullable(UInt32)'));), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000fccaeeb 4. /build/src/Common/ThreadPool.cpp:275: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000fccacb3 5. /build/src/Common/ThreadPool.cpp:323: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fcc4ffc 6. /build/src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000000fcc584d 7. /build/src/Common/ThreadPool.h:279: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x00000000169bf193 8. /build/src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x00000000169bf518 9. /build/src/Server/TCPHandler.cpp:1237: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x00000000168f1525 10. /build/src/Server/TCPHandler.cpp:678: DB::TCPHandler::runImpl() @ 0x00000000168e68e5 11. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 12. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 13. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 14. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 15. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 16. ? @ 0x00007fbc6213eac3 17. ? @ 0x00007fbc621d0850 2025.07.28 11:54:39.768668 [ 5825 ] {} TCPHandler: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=835, jobs=801). (CANNOT_SCHEDULE_TASK), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000fccaeeb 4. /build/src/Common/ThreadPool.cpp:275: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000fccacb3 5. /build/src/Common/ThreadPool.cpp:323: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fcc4ffc 6. /build/src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000000fcc584d 7. /build/src/Common/ThreadPool.h:279: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x00000000169bf193 8. /build/src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x00000000169bf518 9. /build/src/Server/TCPHandler.cpp:1237: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x00000000168f1525 10. /build/src/Server/TCPHandler.cpp:678: DB::TCPHandler::runImpl() @ 0x00000000168e68e5 11. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 12. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 13. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 14. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 15. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 16. ? @ 0x00007fbc6213eac3 17. ? @ 0x00007fbc621d0850 2025.07.28 11:54:39.937076 [ 3962 ] {} test_13.rmt2 (7f9b740d-015c-470e-8cc6-8ba33be0dc63): auto DB::StorageReplicatedMergeTree::processQueueEntry(ReplicatedMergeTreeQueue::SelectedEntryPtr)::(anonymous class)::operator()(LogEntryPtr &) const: Code: 86. DB::HTTPException: Received error from remote server http://146b4357c08d:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Ftest%2F01165%2Ftest_13%2Frmt%2Freplicas%2F1&part=20250728_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.6.10636.altinitytest (altinity build)) '. (RECEIVED_ERROR_FROM_REMOTE_IO_SERVER), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.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 const&, int&&, String const&, unsigned long&&, String const&) @ 0x000000000feda8d9 4. /build/src/IO/HTTPCommon.cpp:104: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x000000000feda6e2 5. /build/src/IO/HTTPCommon.cpp:93: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x000000000feda537 6. /build/src/IO/ReadWriteBufferFromHTTP.cpp:277: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x000000001184a4c4 7. /build/src/IO/ReadWriteBufferFromHTTP.cpp:285: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x000000001184a615 8. /build/src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x000000001184ae59 9. /build/src/IO/ReadWriteBufferFromHTTP.cpp:472: void std::__function::__policy_invoker::__call_impl[abi:se190107]>(std::__function::__policy_storage const*) @ 0x000000001184cedd 10. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001184858b 11. /build/src/IO/ReadWriteBufferFromHTTP.cpp:465: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x000000001184bf0b 12. /build/src/IO/ReadBuffer.h:60: DB::ReadBuffer::next() @ 0x000000000a148c7b 13. /build/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) @ 0x0000000011849fb2 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]>&)>&, 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&) @ 0x0000000011841980 15. /build/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) @ 0x000000001621208e 16. /build/src/Storages/StorageReplicatedMergeTree.cpp:5228: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl[abi:se190107] const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000015f9a5fe 17. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000015ed8bfd 18. /build/src/Storages/StorageReplicatedMergeTree.cpp:2514: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x0000000015ec9aab 19. /build/src/Storages/StorageReplicatedMergeTree.cpp:2349: DB::StorageReplicatedMergeTree::executeLogEntry(DB::ReplicatedMergeTreeLogEntry&) @ 0x0000000015eba91b 20. /build/src/Storages/StorageReplicatedMergeTree.cpp:3876: bool std::__function::__policy_invoker&)>::__call_impl[abi:se190107])::$_1, bool (std::shared_ptr&)>>(std::__function::__policy_storage const*, std::shared_ptr&) @ 0x0000000015f9837e 21. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000165d6fc3 22. /build/src/Storages/StorageReplicatedMergeTree.cpp:3872: DB::StorageReplicatedMergeTree::processQueueEntry(std::shared_ptr) @ 0x0000000015efc18a 23. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001624c1b2 24. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000162f9c70 25. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x00000000162fa55a 26. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc6653 27. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000000fccc4c3 28. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc3d92 29. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fcca080 30. ? @ 0x00007fbc6213eac3 31. ? @ 0x00007fbc621d0850 (version 25.3.6.10636.altinitytest (altinity build)) 2025.07.28 11:54:40.242721 [ 3963 ] {} test_13.rmt2 (7f9b740d-015c-470e-8cc6-8ba33be0dc63): auto DB::StorageReplicatedMergeTree::processQueueEntry(ReplicatedMergeTreeQueue::SelectedEntryPtr)::(anonymous class)::operator()(LogEntryPtr &) const: Code: 86. DB::HTTPException: Received error from remote server http://146b4357c08d:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Ftest%2F01165%2Ftest_13%2Frmt%2Freplicas%2F1&part=20250728_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.6.10636.altinitytest (altinity build)) '. (RECEIVED_ERROR_FROM_REMOTE_IO_SERVER), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.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 const&, int&&, String const&, unsigned long&&, String const&) @ 0x000000000feda8d9 4. /build/src/IO/HTTPCommon.cpp:104: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x000000000feda6e2 5. /build/src/IO/HTTPCommon.cpp:93: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x000000000feda537 6. /build/src/IO/ReadWriteBufferFromHTTP.cpp:277: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x000000001184a4c4 7. /build/src/IO/ReadWriteBufferFromHTTP.cpp:285: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x000000001184a615 8. /build/src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x000000001184ae59 9. /build/src/IO/ReadWriteBufferFromHTTP.cpp:472: void std::__function::__policy_invoker::__call_impl[abi:se190107]>(std::__function::__policy_storage const*) @ 0x000000001184cedd 10. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001184858b 11. /build/src/IO/ReadWriteBufferFromHTTP.cpp:465: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x000000001184bf0b 12. /build/src/IO/ReadBuffer.h:60: DB::ReadBuffer::next() @ 0x000000000a148c7b 13. /build/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) @ 0x0000000011849fb2 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]>&)>&, 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&) @ 0x0000000011841980 15. /build/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) @ 0x000000001621208e 16. /build/src/Storages/StorageReplicatedMergeTree.cpp:5228: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl[abi:se190107] const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000015f9a5fe 17. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000015ed8bfd 18. /build/src/Storages/StorageReplicatedMergeTree.cpp:2514: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x0000000015ec9aab 19. /build/src/Storages/StorageReplicatedMergeTree.cpp:2349: DB::StorageReplicatedMergeTree::executeLogEntry(DB::ReplicatedMergeTreeLogEntry&) @ 0x0000000015eba91b 20. /build/src/Storages/StorageReplicatedMergeTree.cpp:3876: bool std::__function::__policy_invoker&)>::__call_impl[abi:se190107])::$_1, bool (std::shared_ptr&)>>(std::__function::__policy_storage const*, std::shared_ptr&) @ 0x0000000015f9837e 21. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000165d6fc3 22. /build/src/Storages/StorageReplicatedMergeTree.cpp:3872: DB::StorageReplicatedMergeTree::processQueueEntry(std::shared_ptr) @ 0x0000000015efc18a 23. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001624c1b2 24. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000162f9c70 25. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x00000000162fa55a 26. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc6653 27. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000000fccc4c3 28. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc3d92 29. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fcca080 30. ? @ 0x00007fbc6213eac3 31. ? @ 0x00007fbc621d0850 (version 25.3.6.10636.altinitytest (altinity build)) 2025.07.28 11:54:40.689876 [ 3960 ] {} test_13.rmt2 (7f9b740d-015c-470e-8cc6-8ba33be0dc63): auto DB::StorageReplicatedMergeTree::processQueueEntry(ReplicatedMergeTreeQueue::SelectedEntryPtr)::(anonymous class)::operator()(LogEntryPtr &) const: Code: 86. DB::HTTPException: Received error from remote server http://146b4357c08d:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Ftest%2F01165%2Ftest_13%2Frmt%2Freplicas%2F1&part=20250728_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.6.10636.altinitytest (altinity build)) '. (RECEIVED_ERROR_FROM_REMOTE_IO_SERVER), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.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 const&, int&&, String const&, unsigned long&&, String const&) @ 0x000000000feda8d9 4. /build/src/IO/HTTPCommon.cpp:104: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x000000000feda6e2 5. /build/src/IO/HTTPCommon.cpp:93: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x000000000feda537 6. /build/src/IO/ReadWriteBufferFromHTTP.cpp:277: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x000000001184a4c4 7. /build/src/IO/ReadWriteBufferFromHTTP.cpp:285: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x000000001184a615 8. /build/src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x000000001184ae59 9. /build/src/IO/ReadWriteBufferFromHTTP.cpp:472: void std::__function::__policy_invoker::__call_impl[abi:se190107]>(std::__function::__policy_storage const*) @ 0x000000001184cedd 10. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001184858b 11. /build/src/IO/ReadWriteBufferFromHTTP.cpp:465: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x000000001184bf0b 12. /build/src/IO/ReadBuffer.h:60: DB::ReadBuffer::next() @ 0x000000000a148c7b 13. /build/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) @ 0x0000000011849fb2 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]>&)>&, 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&) @ 0x0000000011841980 15. /build/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) @ 0x000000001621208e 16. /build/src/Storages/StorageReplicatedMergeTree.cpp:5228: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl[abi:se190107] const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000015f9a5fe 17. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000015ed8bfd 18. /build/src/Storages/StorageReplicatedMergeTree.cpp:2514: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x0000000015ec9aab 19. /build/src/Storages/StorageReplicatedMergeTree.cpp:2349: DB::StorageReplicatedMergeTree::executeLogEntry(DB::ReplicatedMergeTreeLogEntry&) @ 0x0000000015eba91b 20. /build/src/Storages/StorageReplicatedMergeTree.cpp:3876: bool std::__function::__policy_invoker&)>::__call_impl[abi:se190107])::$_1, bool (std::shared_ptr&)>>(std::__function::__policy_storage const*, std::shared_ptr&) @ 0x0000000015f9837e 21. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000165d6fc3 22. /build/src/Storages/StorageReplicatedMergeTree.cpp:3872: DB::StorageReplicatedMergeTree::processQueueEntry(std::shared_ptr) @ 0x0000000015efc18a 23. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001624c1b2 24. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000162f9c70 25. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x00000000162fa55a 26. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc6653 27. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000000fccc4c3 28. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc3d92 29. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fcca080 30. ? @ 0x00007fbc6213eac3 31. ? @ 0x00007fbc621d0850 (version 25.3.6.10636.altinitytest (altinity build)) 2025.07.28 11:54:41.549000 [ 3970 ] {} test_13.rmt2 (7f9b740d-015c-470e-8cc6-8ba33be0dc63): auto DB::StorageReplicatedMergeTree::processQueueEntry(ReplicatedMergeTreeQueue::SelectedEntryPtr)::(anonymous class)::operator()(LogEntryPtr &) const: Code: 86. DB::HTTPException: Received error from remote server http://146b4357c08d:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Ftest%2F01165%2Ftest_13%2Frmt%2Freplicas%2F1&part=20250728_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.6.10636.altinitytest (altinity build)) '. (RECEIVED_ERROR_FROM_REMOTE_IO_SERVER), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.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 const&, int&&, String const&, unsigned long&&, String const&) @ 0x000000000feda8d9 4. /build/src/IO/HTTPCommon.cpp:104: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x000000000feda6e2 5. /build/src/IO/HTTPCommon.cpp:93: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x000000000feda537 6. /build/src/IO/ReadWriteBufferFromHTTP.cpp:277: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x000000001184a4c4 7. /build/src/IO/ReadWriteBufferFromHTTP.cpp:285: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x000000001184a615 8. /build/src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x000000001184ae59 9. /build/src/IO/ReadWriteBufferFromHTTP.cpp:472: void std::__function::__policy_invoker::__call_impl[abi:se190107]>(std::__function::__policy_storage const*) @ 0x000000001184cedd 10. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001184858b 11. /build/src/IO/ReadWriteBufferFromHTTP.cpp:465: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x000000001184bf0b 12. /build/src/IO/ReadBuffer.h:60: DB::ReadBuffer::next() @ 0x000000000a148c7b 13. /build/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) @ 0x0000000011849fb2 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]>&)>&, 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&) @ 0x0000000011841980 15. /build/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) @ 0x000000001621208e 16. /build/src/Storages/StorageReplicatedMergeTree.cpp:5228: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl[abi:se190107] const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000015f9a5fe 17. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000015ed8bfd 18. /build/src/Storages/StorageReplicatedMergeTree.cpp:2514: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x0000000015ec9aab 19. /build/src/Storages/StorageReplicatedMergeTree.cpp:2349: DB::StorageReplicatedMergeTree::executeLogEntry(DB::ReplicatedMergeTreeLogEntry&) @ 0x0000000015eba91b 20. /build/src/Storages/StorageReplicatedMergeTree.cpp:3876: bool std::__function::__policy_invoker&)>::__call_impl[abi:se190107])::$_1, bool (std::shared_ptr&)>>(std::__function::__policy_storage const*, std::shared_ptr&) @ 0x0000000015f9837e 21. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000165d6fc3 22. /build/src/Storages/StorageReplicatedMergeTree.cpp:3872: DB::StorageReplicatedMergeTree::processQueueEntry(std::shared_ptr) @ 0x0000000015efc18a 23. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001624c1b2 24. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000162f9c70 25. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x00000000162fa55a 26. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc6653 27. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000000fccc4c3 28. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc3d92 29. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fcca080 30. ? @ 0x00007fbc6213eac3 31. ? @ 0x00007fbc621d0850 (version 25.3.6.10636.altinitytest (altinity build)) 2025.07.28 11:54:41.751014 [ 3966 ] {} test_13.rmt2 (7f9b740d-015c-470e-8cc6-8ba33be0dc63): auto DB::StorageReplicatedMergeTree::processQueueEntry(ReplicatedMergeTreeQueue::SelectedEntryPtr)::(anonymous class)::operator()(LogEntryPtr &) const: Code: 86. DB::HTTPException: Received error from remote server http://146b4357c08d:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Ftest%2F01165%2Ftest_13%2Frmt%2Freplicas%2F1&part=20250728_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.6.10636.altinitytest (altinity build)) '. (RECEIVED_ERROR_FROM_REMOTE_IO_SERVER), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.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 const&, int&&, String const&, unsigned long&&, String const&) @ 0x000000000feda8d9 4. /build/src/IO/HTTPCommon.cpp:104: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x000000000feda6e2 5. /build/src/IO/HTTPCommon.cpp:93: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x000000000feda537 6. /build/src/IO/ReadWriteBufferFromHTTP.cpp:277: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x000000001184a4c4 7. /build/src/IO/ReadWriteBufferFromHTTP.cpp:285: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x000000001184a615 8. /build/src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x000000001184ae59 9. /build/src/IO/ReadWriteBufferFromHTTP.cpp:472: void std::__function::__policy_invoker::__call_impl[abi:se190107]>(std::__function::__policy_storage const*) @ 0x000000001184cedd 10. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001184858b 11. /build/src/IO/ReadWriteBufferFromHTTP.cpp:465: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x000000001184bf0b 12. /build/src/IO/ReadBuffer.h:60: DB::ReadBuffer::next() @ 0x000000000a148c7b 13. /build/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) @ 0x0000000011849fb2 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]>&)>&, 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&) @ 0x0000000011841980 15. /build/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) @ 0x000000001621208e 16. /build/src/Storages/StorageReplicatedMergeTree.cpp:5228: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl[abi:se190107] const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000015f9a5fe 17. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000015ed8bfd 18. /build/src/Storages/StorageReplicatedMergeTree.cpp:2514: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x0000000015ec9aab 19. /build/src/Storages/StorageReplicatedMergeTree.cpp:2349: DB::StorageReplicatedMergeTree::executeLogEntry(DB::ReplicatedMergeTreeLogEntry&) @ 0x0000000015eba91b 20. /build/src/Storages/StorageReplicatedMergeTree.cpp:3876: bool std::__function::__policy_invoker&)>::__call_impl[abi:se190107])::$_1, bool (std::shared_ptr&)>>(std::__function::__policy_storage const*, std::shared_ptr&) @ 0x0000000015f9837e 21. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000165d6fc3 22. /build/src/Storages/StorageReplicatedMergeTree.cpp:3872: DB::StorageReplicatedMergeTree::processQueueEntry(std::shared_ptr) @ 0x0000000015efc18a 23. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001624c1b2 24. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000162f9c70 25. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x00000000162fa55a 26. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc6653 27. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000000fccc4c3 28. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc3d92 29. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fcca080 30. ? @ 0x00007fbc6213eac3 31. ? @ 0x00007fbc621d0850 (version 25.3.6.10636.altinitytest (altinity build)) 2025.07.28 11:54:42.293234 [ 3977 ] {} test_13.rmt2 (7f9b740d-015c-470e-8cc6-8ba33be0dc63): auto DB::StorageReplicatedMergeTree::processQueueEntry(ReplicatedMergeTreeQueue::SelectedEntryPtr)::(anonymous class)::operator()(LogEntryPtr &) const: Code: 86. DB::HTTPException: Received error from remote server http://146b4357c08d:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Ftest%2F01165%2Ftest_13%2Frmt%2Freplicas%2F1&part=20250728_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.6.10636.altinitytest (altinity build)) '. (RECEIVED_ERROR_FROM_REMOTE_IO_SERVER), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.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 const&, int&&, String const&, unsigned long&&, String const&) @ 0x000000000feda8d9 4. /build/src/IO/HTTPCommon.cpp:104: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x000000000feda6e2 5. /build/src/IO/HTTPCommon.cpp:93: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x000000000feda537 6. /build/src/IO/ReadWriteBufferFromHTTP.cpp:277: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x000000001184a4c4 7. /build/src/IO/ReadWriteBufferFromHTTP.cpp:285: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x000000001184a615 8. /build/src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x000000001184ae59 9. /build/src/IO/ReadWriteBufferFromHTTP.cpp:472: void std::__function::__policy_invoker::__call_impl[abi:se190107]>(std::__function::__policy_storage const*) @ 0x000000001184cedd 10. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001184858b 11. /build/src/IO/ReadWriteBufferFromHTTP.cpp:465: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x000000001184bf0b 12. /build/src/IO/ReadBuffer.h:60: DB::ReadBuffer::next() @ 0x000000000a148c7b 13. /build/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) @ 0x0000000011849fb2 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]>&)>&, 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&) @ 0x0000000011841980 15. /build/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) @ 0x000000001621208e 16. /build/src/Storages/StorageReplicatedMergeTree.cpp:5228: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl[abi:se190107] const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000015f9a5fe 17. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000015ed8bfd 18. /build/src/Storages/StorageReplicatedMergeTree.cpp:2514: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x0000000015ec9aab 19. /build/src/Storages/StorageReplicatedMergeTree.cpp:2349: DB::StorageReplicatedMergeTree::executeLogEntry(DB::ReplicatedMergeTreeLogEntry&) @ 0x0000000015eba91b 20. /build/src/Storages/StorageReplicatedMergeTree.cpp:3876: bool std::__function::__policy_invoker&)>::__call_impl[abi:se190107])::$_1, bool (std::shared_ptr&)>>(std::__function::__policy_storage const*, std::shared_ptr&) @ 0x0000000015f9837e 21. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000165d6fc3 22. /build/src/Storages/StorageReplicatedMergeTree.cpp:3872: DB::StorageReplicatedMergeTree::processQueueEntry(std::shared_ptr) @ 0x0000000015efc18a 23. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001624c1b2 24. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000162f9c70 25. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x00000000162fa55a 26. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc6653 27. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000000fccc4c3 28. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc3d92 29. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fcca080 30. ? @ 0x00007fbc6213eac3 31. ? @ 0x00007fbc621d0850 (version 25.3.6.10636.altinitytest (altinity build)) 2025.07.28 11:54:42.555999 [ 3976 ] {} test_13.rmt2 (7f9b740d-015c-470e-8cc6-8ba33be0dc63): auto DB::StorageReplicatedMergeTree::processQueueEntry(ReplicatedMergeTreeQueue::SelectedEntryPtr)::(anonymous class)::operator()(LogEntryPtr &) const: Code: 86. DB::HTTPException: Received error from remote server http://146b4357c08d:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Ftest%2F01165%2Ftest_13%2Frmt%2Freplicas%2F1&part=20250728_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.6.10636.altinitytest (altinity build)) '. (RECEIVED_ERROR_FROM_REMOTE_IO_SERVER), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.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 const&, int&&, String const&, unsigned long&&, String const&) @ 0x000000000feda8d9 4. /build/src/IO/HTTPCommon.cpp:104: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x000000000feda6e2 5. /build/src/IO/HTTPCommon.cpp:93: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x000000000feda537 6. /build/src/IO/ReadWriteBufferFromHTTP.cpp:277: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x000000001184a4c4 7. /build/src/IO/ReadWriteBufferFromHTTP.cpp:285: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x000000001184a615 8. /build/src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x000000001184ae59 9. /build/src/IO/ReadWriteBufferFromHTTP.cpp:472: void std::__function::__policy_invoker::__call_impl[abi:se190107]>(std::__function::__policy_storage const*) @ 0x000000001184cedd 10. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001184858b 11. /build/src/IO/ReadWriteBufferFromHTTP.cpp:465: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x000000001184bf0b 12. /build/src/IO/ReadBuffer.h:60: DB::ReadBuffer::next() @ 0x000000000a148c7b 13. /build/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) @ 0x0000000011849fb2 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]>&)>&, 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&) @ 0x0000000011841980 15. /build/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) @ 0x000000001621208e 16. /build/src/Storages/StorageReplicatedMergeTree.cpp:5228: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl[abi:se190107] const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000015f9a5fe 17. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000015ed8bfd 18. /build/src/Storages/StorageReplicatedMergeTree.cpp:2514: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x0000000015ec9aab 19. /build/src/Storages/StorageReplicatedMergeTree.cpp:2349: DB::StorageReplicatedMergeTree::executeLogEntry(DB::ReplicatedMergeTreeLogEntry&) @ 0x0000000015eba91b 20. /build/src/Storages/StorageReplicatedMergeTree.cpp:3876: bool std::__function::__policy_invoker&)>::__call_impl[abi:se190107])::$_1, bool (std::shared_ptr&)>>(std::__function::__policy_storage const*, std::shared_ptr&) @ 0x0000000015f9837e 21. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000165d6fc3 22. /build/src/Storages/StorageReplicatedMergeTree.cpp:3872: DB::StorageReplicatedMergeTree::processQueueEntry(std::shared_ptr) @ 0x0000000015efc18a 23. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001624c1b2 24. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000162f9c70 25. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x00000000162fa55a 26. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc6653 27. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000000fccc4c3 28. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc3d92 29. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fcca080 30. ? @ 0x00007fbc6213eac3 31. ? @ 0x00007fbc621d0850 (version 25.3.6.10636.altinitytest (altinity build)) 2025.07.28 11:54:42.957763 [ 3944 ] {057d9f5f-935e-4fb0-aa4d-d5515c7b79d1::202507_1_51_10} virtual bool DB::MergePlainMergeTreeTask::executeStep(): Exception is in merge_task.: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=28, jobs=0). (CANNOT_SCHEDULE_TASK), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000fccaeeb 4. /build/src/Common/ThreadPool.cpp:275: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000fccc813 5. /build/src/Common/ThreadPool.cpp:323: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fcc7bbc 6. /build/src/Common/ThreadPool.cpp:494: ThreadPoolImpl>::scheduleOrThrowOnError(std::function, Priority) @ 0x000000000fcc7a0e 7. /build/src/Common/threadPoolCallbackRunner.h:52: std::future> std::__function::__policy_invoker> (DB::MergeTreeMarksLoader::loadMarksAsync()::$_0&&, Priority)>::__call_impl[abi:se190107]> (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&&) @ 0x0000000016474731 8. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000016471940 9. /build/src/Storages/MergeTree/MergeTreeMarksLoader.cpp:83: DB::MergeTreeMarksLoader::startAsyncLoad() @ 0x000000001647173f 10. /build/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) @ 0x000000001648df37 11. /build/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&&) @ 0x00000000163c608d 12. /build/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 @ 0x00000000163c27d4 13. /build/src/Storages/MergeTree/MergeTreeReadTask.cpp:60: DB::MergeTreeReadTask::createReaders(std::shared_ptr const&, DB::MergeTreeReadTask::Extras const&, DB::MarkRanges const&) @ 0x00000000164b5386 14. /build/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) @ 0x00000000164ae717 15. /build/contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: DB::MergeTreeSequentialSource* std::construct_at[abi:se190107] 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&) @ 0x00000000164b4832 16. /build/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) @ 0x00000000164b091a 17. /build/src/Storages/MergeTree/MergeTreeSequentialSource.cpp:384: DB::ReadFromPart::initializePipeline(DB::QueryPipelineBuilder&, DB::BuildQueryPipelineSettings const&) @ 0x00000000164b31ca 18. /build/src/Processors/QueryPlan/ISourceStep.cpp:20: DB::ISourceStep::updatePipeline(std::vector>, std::allocator>>>, DB::BuildQueryPipelineSettings const&) @ 0x0000000016dd18d0 19. /build/src/Processors/QueryPlan/QueryPlan.cpp:201: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x0000000016e0076f 20. /build/src/Storages/MergeTree/MergeTask.cpp:1910: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::createMergedStream() const @ 0x00000000162d4627 21. /build/src/Storages/MergeTree/MergeTask.cpp:567: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::prepare() const @ 0x00000000162ce7b3 22. /build/src/Storages/MergeTree/MergeTask.cpp:710: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::execute() @ 0x00000000162d5ad9 23. /build/src/Storages/MergeTree/MergeTask.cpp:1485: DB::MergeTask::execute() @ 0x00000000162dbf2a 24. /build/src/Storages/MergeTree/MergePlainMergeTreeTask.cpp:57: DB::MergePlainMergeTreeTask::executeStep() @ 0x000000001666e865 25. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000162fc850 26. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x00000000162fd193 27. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc6653 28. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000000fccc4c3 29. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc3d92 30. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fcca080 31. ? @ 0x00007fbc6213eac3 (version 25.3.6.10636.altinitytest (altinity build)) 2025.07.28 11:54:42.968777 [ 3944 ] {} MergeTreeBackgroundExecutor: Exception while executing background task {057d9f5f-935e-4fb0-aa4d-d5515c7b79d1::202507_1_51_10}: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=28, jobs=0). (CANNOT_SCHEDULE_TASK), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000fccaeeb 4. /build/src/Common/ThreadPool.cpp:275: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000fccc813 5. /build/src/Common/ThreadPool.cpp:323: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fcc7bbc 6. /build/src/Common/ThreadPool.cpp:494: ThreadPoolImpl>::scheduleOrThrowOnError(std::function, Priority) @ 0x000000000fcc7a0e 7. /build/src/Common/threadPoolCallbackRunner.h:52: std::future> std::__function::__policy_invoker> (DB::MergeTreeMarksLoader::loadMarksAsync()::$_0&&, Priority)>::__call_impl[abi:se190107]> (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&&) @ 0x0000000016474731 8. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000016471940 9. /build/src/Storages/MergeTree/MergeTreeMarksLoader.cpp:83: DB::MergeTreeMarksLoader::startAsyncLoad() @ 0x000000001647173f 10. /build/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) @ 0x000000001648df37 11. /build/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&&) @ 0x00000000163c608d 12. /build/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 @ 0x00000000163c27d4 13. /build/src/Storages/MergeTree/MergeTreeReadTask.cpp:60: DB::MergeTreeReadTask::createReaders(std::shared_ptr const&, DB::MergeTreeReadTask::Extras const&, DB::MarkRanges const&) @ 0x00000000164b5386 14. /build/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) @ 0x00000000164ae717 15. /build/contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: DB::MergeTreeSequentialSource* std::construct_at[abi:se190107] 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&) @ 0x00000000164b4832 16. /build/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) @ 0x00000000164b091a 17. /build/src/Storages/MergeTree/MergeTreeSequentialSource.cpp:384: DB::ReadFromPart::initializePipeline(DB::QueryPipelineBuilder&, DB::BuildQueryPipelineSettings const&) @ 0x00000000164b31ca 18. /build/src/Processors/QueryPlan/ISourceStep.cpp:20: DB::ISourceStep::updatePipeline(std::vector>, std::allocator>>>, DB::BuildQueryPipelineSettings const&) @ 0x0000000016dd18d0 19. /build/src/Processors/QueryPlan/QueryPlan.cpp:201: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x0000000016e0076f 20. /build/src/Storages/MergeTree/MergeTask.cpp:1910: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::createMergedStream() const @ 0x00000000162d4627 21. /build/src/Storages/MergeTree/MergeTask.cpp:567: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::prepare() const @ 0x00000000162ce7b3 22. /build/src/Storages/MergeTree/MergeTask.cpp:710: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::execute() @ 0x00000000162d5ad9 23. /build/src/Storages/MergeTree/MergeTask.cpp:1485: DB::MergeTask::execute() @ 0x00000000162dbf2a 24. /build/src/Storages/MergeTree/MergePlainMergeTreeTask.cpp:57: DB::MergePlainMergeTreeTask::executeStep() @ 0x000000001666e865 25. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000162fc850 26. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x00000000162fd193 27. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc6653 28. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000000fccc4c3 29. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc3d92 30. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fcca080 31. ? @ 0x00007fbc6213eac3 (version 25.3.6.10636.altinitytest (altinity build)) 2025.07.28 11:54:43.566438 [ 3969 ] {} test_13.rmt2 (7f9b740d-015c-470e-8cc6-8ba33be0dc63): auto DB::StorageReplicatedMergeTree::processQueueEntry(ReplicatedMergeTreeQueue::SelectedEntryPtr)::(anonymous class)::operator()(LogEntryPtr &) const: Code: 86. DB::HTTPException: Received error from remote server http://146b4357c08d:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Ftest%2F01165%2Ftest_13%2Frmt%2Freplicas%2F1&part=20250728_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.6.10636.altinitytest (altinity build)) '. (RECEIVED_ERROR_FROM_REMOTE_IO_SERVER), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.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 const&, int&&, String const&, unsigned long&&, String const&) @ 0x000000000feda8d9 4. /build/src/IO/HTTPCommon.cpp:104: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x000000000feda6e2 5. /build/src/IO/HTTPCommon.cpp:93: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x000000000feda537 6. /build/src/IO/ReadWriteBufferFromHTTP.cpp:277: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x000000001184a4c4 7. /build/src/IO/ReadWriteBufferFromHTTP.cpp:285: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x000000001184a615 8. /build/src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x000000001184ae59 9. /build/src/IO/ReadWriteBufferFromHTTP.cpp:472: void std::__function::__policy_invoker::__call_impl[abi:se190107]>(std::__function::__policy_storage const*) @ 0x000000001184cedd 10. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001184858b 11. /build/src/IO/ReadWriteBufferFromHTTP.cpp:465: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x000000001184bf0b 12. /build/src/IO/ReadBuffer.h:60: DB::ReadBuffer::next() @ 0x000000000a148c7b 13. /build/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) @ 0x0000000011849fb2 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]>&)>&, 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&) @ 0x0000000011841980 15. /build/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) @ 0x000000001621208e 16. /build/src/Storages/StorageReplicatedMergeTree.cpp:5228: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl[abi:se190107] const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000015f9a5fe 17. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000015ed8bfd 18. /build/src/Storages/StorageReplicatedMergeTree.cpp:2514: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x0000000015ec9aab 19. /build/src/Storages/StorageReplicatedMergeTree.cpp:2349: DB::StorageReplicatedMergeTree::executeLogEntry(DB::ReplicatedMergeTreeLogEntry&) @ 0x0000000015eba91b 20. /build/src/Storages/StorageReplicatedMergeTree.cpp:3876: bool std::__function::__policy_invoker&)>::__call_impl[abi:se190107])::$_1, bool (std::shared_ptr&)>>(std::__function::__policy_storage const*, std::shared_ptr&) @ 0x0000000015f9837e 21. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000165d6fc3 22. /build/src/Storages/StorageReplicatedMergeTree.cpp:3872: DB::StorageReplicatedMergeTree::processQueueEntry(std::shared_ptr) @ 0x0000000015efc18a 23. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001624c1b2 24. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000162f9c70 25. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x00000000162fa55a 26. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc6653 27. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000000fccc4c3 28. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc3d92 29. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fcca080 30. ? @ 0x00007fbc6213eac3 31. ? @ 0x00007fbc621d0850 (version 25.3.6.10636.altinitytest (altinity build)) 2025.07.28 11:54:44.072681 [ 11826 ] {} 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. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception>&, String>(int, FormatStringHelperImpl>&>::type, std::type_identity::type>, std::basic_string_view>&, String&&) @ 0x000000001385a5eb 4. /build/src/Access/SettingsConstraints.cpp:376: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000013859b18 5. /build/src/Access/SettingsConstraints.cpp:300: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000013858faf 6. /build/src/Access/SettingsConstraints.cpp:209: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000013859223 7. /build/src/Interpreters/Context.cpp:2690: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000014436134 8. /build/src/Interpreters/Context.cpp:2729: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x000000001443662b 9. /build/src/Server/HTTPHandler.cpp:457: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000001686d165 10. /build/src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x0000000016870807 11. /build/src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x0000000016907e99 12. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 13. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 14. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 15. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 16. ? @ 0x00007fbc6213eac3 17. ? @ 0x00007fbc621d0850 (version 25.3.6.10636.altinitytest (altinity build)) 2025.07.28 11:54:44.109101 [ 3961 ] {} test_13.rmt2 (7f9b740d-015c-470e-8cc6-8ba33be0dc63): auto DB::StorageReplicatedMergeTree::processQueueEntry(ReplicatedMergeTreeQueue::SelectedEntryPtr)::(anonymous class)::operator()(LogEntryPtr &) const: Code: 86. DB::HTTPException: Received error from remote server http://146b4357c08d:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Ftest%2F01165%2Ftest_13%2Frmt%2Freplicas%2F1&part=20250728_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.6.10636.altinitytest (altinity build)) '. (RECEIVED_ERROR_FROM_REMOTE_IO_SERVER), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.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 const&, int&&, String const&, unsigned long&&, String const&) @ 0x000000000feda8d9 4. /build/src/IO/HTTPCommon.cpp:104: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x000000000feda6e2 5. /build/src/IO/HTTPCommon.cpp:93: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x000000000feda537 6. /build/src/IO/ReadWriteBufferFromHTTP.cpp:277: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x000000001184a4c4 7. /build/src/IO/ReadWriteBufferFromHTTP.cpp:285: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x000000001184a615 8. /build/src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x000000001184ae59 9. /build/src/IO/ReadWriteBufferFromHTTP.cpp:472: void std::__function::__policy_invoker::__call_impl[abi:se190107]>(std::__function::__policy_storage const*) @ 0x000000001184cedd 10. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001184858b 11. /build/src/IO/ReadWriteBufferFromHTTP.cpp:465: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x000000001184bf0b 12. /build/src/IO/ReadBuffer.h:60: DB::ReadBuffer::next() @ 0x000000000a148c7b 13. /build/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) @ 0x0000000011849fb2 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]>&)>&, 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&) @ 0x0000000011841980 15. /build/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) @ 0x000000001621208e 16. /build/src/Storages/StorageReplicatedMergeTree.cpp:5228: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl[abi:se190107] const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000015f9a5fe 17. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000015ed8bfd 18. /build/src/Storages/StorageReplicatedMergeTree.cpp:2514: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x0000000015ec9aab 19. /build/src/Storages/StorageReplicatedMergeTree.cpp:2349: DB::StorageReplicatedMergeTree::executeLogEntry(DB::ReplicatedMergeTreeLogEntry&) @ 0x0000000015eba91b 20. /build/src/Storages/StorageReplicatedMergeTree.cpp:3876: bool std::__function::__policy_invoker&)>::__call_impl[abi:se190107])::$_1, bool (std::shared_ptr&)>>(std::__function::__policy_storage const*, std::shared_ptr&) @ 0x0000000015f9837e 21. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000165d6fc3 22. /build/src/Storages/StorageReplicatedMergeTree.cpp:3872: DB::StorageReplicatedMergeTree::processQueueEntry(std::shared_ptr) @ 0x0000000015efc18a 23. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001624c1b2 24. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000162f9c70 25. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x00000000162fa55a 26. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc6653 27. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000000fccc4c3 28. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc3d92 29. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fcca080 30. ? @ 0x00007fbc6213eac3 31. ? @ 0x00007fbc621d0850 (version 25.3.6.10636.altinitytest (altinity build)) 2025.07.28 11:54:44.338054 [ 3974 ] {} test_13.rmt2 (7f9b740d-015c-470e-8cc6-8ba33be0dc63): auto DB::StorageReplicatedMergeTree::processQueueEntry(ReplicatedMergeTreeQueue::SelectedEntryPtr)::(anonymous class)::operator()(LogEntryPtr &) const: Code: 86. DB::HTTPException: Received error from remote server http://146b4357c08d:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Ftest%2F01165%2Ftest_13%2Frmt%2Freplicas%2F1&part=20250728_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.6.10636.altinitytest (altinity build)) '. (RECEIVED_ERROR_FROM_REMOTE_IO_SERVER), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.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 const&, int&&, String const&, unsigned long&&, String const&) @ 0x000000000feda8d9 4. /build/src/IO/HTTPCommon.cpp:104: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x000000000feda6e2 5. /build/src/IO/HTTPCommon.cpp:93: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x000000000feda537 6. /build/src/IO/ReadWriteBufferFromHTTP.cpp:277: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x000000001184a4c4 7. /build/src/IO/ReadWriteBufferFromHTTP.cpp:285: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x000000001184a615 8. /build/src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x000000001184ae59 9. /build/src/IO/ReadWriteBufferFromHTTP.cpp:472: void std::__function::__policy_invoker::__call_impl[abi:se190107]>(std::__function::__policy_storage const*) @ 0x000000001184cedd 10. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001184858b 11. /build/src/IO/ReadWriteBufferFromHTTP.cpp:465: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x000000001184bf0b 12. /build/src/IO/ReadBuffer.h:60: DB::ReadBuffer::next() @ 0x000000000a148c7b 13. /build/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) @ 0x0000000011849fb2 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]>&)>&, 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&) @ 0x0000000011841980 15. /build/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) @ 0x000000001621208e 16. /build/src/Storages/StorageReplicatedMergeTree.cpp:5228: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl[abi:se190107] const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000015f9a5fe 17. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000015ed8bfd 18. /build/src/Storages/StorageReplicatedMergeTree.cpp:2514: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x0000000015ec9aab 19. /build/src/Storages/StorageReplicatedMergeTree.cpp:2349: DB::StorageReplicatedMergeTree::executeLogEntry(DB::ReplicatedMergeTreeLogEntry&) @ 0x0000000015eba91b 20. /build/src/Storages/StorageReplicatedMergeTree.cpp:3876: bool std::__function::__policy_invoker&)>::__call_impl[abi:se190107])::$_1, bool (std::shared_ptr&)>>(std::__function::__policy_storage const*, std::shared_ptr&) @ 0x0000000015f9837e 21. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000165d6fc3 22. /build/src/Storages/StorageReplicatedMergeTree.cpp:3872: DB::StorageReplicatedMergeTree::processQueueEntry(std::shared_ptr) @ 0x0000000015efc18a 23. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001624c1b2 24. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000162f9c70 25. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x00000000162fa55a 26. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc6653 27. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000000fccc4c3 28. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc3d92 29. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fcca080 30. ? @ 0x00007fbc6213eac3 31. ? @ 0x00007fbc621d0850 (version 25.3.6.10636.altinitytest (altinity build)) 2025.07.28 11:54:45.241443 [ 3977 ] {} test_13.rmt2 (7f9b740d-015c-470e-8cc6-8ba33be0dc63): auto DB::StorageReplicatedMergeTree::processQueueEntry(ReplicatedMergeTreeQueue::SelectedEntryPtr)::(anonymous class)::operator()(LogEntryPtr &) const: Code: 86. DB::HTTPException: Received error from remote server http://146b4357c08d:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Ftest%2F01165%2Ftest_13%2Frmt%2Freplicas%2F1&part=20250728_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.6.10636.altinitytest (altinity build)) '. (RECEIVED_ERROR_FROM_REMOTE_IO_SERVER), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.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 const&, int&&, String const&, unsigned long&&, String const&) @ 0x000000000feda8d9 4. /build/src/IO/HTTPCommon.cpp:104: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x000000000feda6e2 5. /build/src/IO/HTTPCommon.cpp:93: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x000000000feda537 6. /build/src/IO/ReadWriteBufferFromHTTP.cpp:277: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x000000001184a4c4 7. /build/src/IO/ReadWriteBufferFromHTTP.cpp:285: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x000000001184a615 8. /build/src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x000000001184ae59 9. /build/src/IO/ReadWriteBufferFromHTTP.cpp:472: void std::__function::__policy_invoker::__call_impl[abi:se190107]>(std::__function::__policy_storage const*) @ 0x000000001184cedd 10. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001184858b 11. /build/src/IO/ReadWriteBufferFromHTTP.cpp:465: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x000000001184bf0b 12. /build/src/IO/ReadBuffer.h:60: DB::ReadBuffer::next() @ 0x000000000a148c7b 13. /build/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) @ 0x0000000011849fb2 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]>&)>&, 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&) @ 0x0000000011841980 15. /build/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) @ 0x000000001621208e 16. /build/src/Storages/StorageReplicatedMergeTree.cpp:5228: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl[abi:se190107] const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000015f9a5fe 17. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000015ed8bfd 18. /build/src/Storages/StorageReplicatedMergeTree.cpp:2514: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x0000000015ec9aab 19. /build/src/Storages/StorageReplicatedMergeTree.cpp:2349: DB::StorageReplicatedMergeTree::executeLogEntry(DB::ReplicatedMergeTreeLogEntry&) @ 0x0000000015eba91b 20. /build/src/Storages/StorageReplicatedMergeTree.cpp:3876: bool std::__function::__policy_invoker&)>::__call_impl[abi:se190107])::$_1, bool (std::shared_ptr&)>>(std::__function::__policy_storage const*, std::shared_ptr&) @ 0x0000000015f9837e 21. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000165d6fc3 22. /build/src/Storages/StorageReplicatedMergeTree.cpp:3872: DB::StorageReplicatedMergeTree::processQueueEntry(std::shared_ptr) @ 0x0000000015efc18a 23. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001624c1b2 24. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000162f9c70 25. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x00000000162fa55a 26. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc6653 27. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000000fccc4c3 28. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc3d92 29. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fcca080 30. ? @ 0x00007fbc6213eac3 31. ? @ 0x00007fbc621d0850 (version 25.3.6.10636.altinitytest (altinity build)) 2025.07.28 11:54:46.160475 [ 3974 ] {} test_13.rmt2 (7f9b740d-015c-470e-8cc6-8ba33be0dc63): auto DB::StorageReplicatedMergeTree::processQueueEntry(ReplicatedMergeTreeQueue::SelectedEntryPtr)::(anonymous class)::operator()(LogEntryPtr &) const: Code: 86. DB::HTTPException: Received error from remote server http://146b4357c08d:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Ftest%2F01165%2Ftest_13%2Frmt%2Freplicas%2F1&part=20250728_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.6.10636.altinitytest (altinity build)) '. (RECEIVED_ERROR_FROM_REMOTE_IO_SERVER), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.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 const&, int&&, String const&, unsigned long&&, String const&) @ 0x000000000feda8d9 4. /build/src/IO/HTTPCommon.cpp:104: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x000000000feda6e2 5. /build/src/IO/HTTPCommon.cpp:93: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x000000000feda537 6. /build/src/IO/ReadWriteBufferFromHTTP.cpp:277: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x000000001184a4c4 7. /build/src/IO/ReadWriteBufferFromHTTP.cpp:285: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x000000001184a615 8. /build/src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x000000001184ae59 9. /build/src/IO/ReadWriteBufferFromHTTP.cpp:472: void std::__function::__policy_invoker::__call_impl[abi:se190107]>(std::__function::__policy_storage const*) @ 0x000000001184cedd 10. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001184858b 11. /build/src/IO/ReadWriteBufferFromHTTP.cpp:465: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x000000001184bf0b 12. /build/src/IO/ReadBuffer.h:60: DB::ReadBuffer::next() @ 0x000000000a148c7b 13. /build/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) @ 0x0000000011849fb2 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]>&)>&, 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&) @ 0x0000000011841980 15. /build/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) @ 0x000000001621208e 16. /build/src/Storages/StorageReplicatedMergeTree.cpp:5228: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl[abi:se190107] const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000015f9a5fe 17. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000015ed8bfd 18. /build/src/Storages/StorageReplicatedMergeTree.cpp:2514: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x0000000015ec9aab 19. /build/src/Storages/StorageReplicatedMergeTree.cpp:2349: DB::StorageReplicatedMergeTree::executeLogEntry(DB::ReplicatedMergeTreeLogEntry&) @ 0x0000000015eba91b 20. /build/src/Storages/StorageReplicatedMergeTree.cpp:3876: bool std::__function::__policy_invoker&)>::__call_impl[abi:se190107])::$_1, bool (std::shared_ptr&)>>(std::__function::__policy_storage const*, std::shared_ptr&) @ 0x0000000015f9837e 21. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000165d6fc3 22. /build/src/Storages/StorageReplicatedMergeTree.cpp:3872: DB::StorageReplicatedMergeTree::processQueueEntry(std::shared_ptr) @ 0x0000000015efc18a 23. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001624c1b2 24. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000162f9c70 25. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x00000000162fa55a 26. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc6653 27. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000000fccc4c3 28. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc3d92 29. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fcca080 30. ? @ 0x00007fbc6213eac3 31. ? @ 0x00007fbc621d0850 (version 25.3.6.10636.altinitytest (altinity build)) 2025.07.28 11:54:46.390856 [ 3970 ] {} test_13.rmt2 (7f9b740d-015c-470e-8cc6-8ba33be0dc63): auto DB::StorageReplicatedMergeTree::processQueueEntry(ReplicatedMergeTreeQueue::SelectedEntryPtr)::(anonymous class)::operator()(LogEntryPtr &) const: Code: 86. DB::HTTPException: Received error from remote server http://146b4357c08d:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Ftest%2F01165%2Ftest_13%2Frmt%2Freplicas%2F1&part=20250728_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.6.10636.altinitytest (altinity build)) '. (RECEIVED_ERROR_FROM_REMOTE_IO_SERVER), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.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 const&, int&&, String const&, unsigned long&&, String const&) @ 0x000000000feda8d9 4. /build/src/IO/HTTPCommon.cpp:104: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x000000000feda6e2 5. /build/src/IO/HTTPCommon.cpp:93: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x000000000feda537 6. /build/src/IO/ReadWriteBufferFromHTTP.cpp:277: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x000000001184a4c4 7. /build/src/IO/ReadWriteBufferFromHTTP.cpp:285: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x000000001184a615 8. /build/src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x000000001184ae59 9. /build/src/IO/ReadWriteBufferFromHTTP.cpp:472: void std::__function::__policy_invoker::__call_impl[abi:se190107]>(std::__function::__policy_storage const*) @ 0x000000001184cedd 10. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001184858b 11. /build/src/IO/ReadWriteBufferFromHTTP.cpp:465: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x000000001184bf0b 12. /build/src/IO/ReadBuffer.h:60: DB::ReadBuffer::next() @ 0x000000000a148c7b 13. /build/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) @ 0x0000000011849fb2 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]>&)>&, 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&) @ 0x0000000011841980 15. /build/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) @ 0x000000001621208e 16. /build/src/Storages/StorageReplicatedMergeTree.cpp:5228: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl[abi:se190107] const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000015f9a5fe 17. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000015ed8bfd 18. /build/src/Storages/StorageReplicatedMergeTree.cpp:2514: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x0000000015ec9aab 19. /build/src/Storages/StorageReplicatedMergeTree.cpp:2349: DB::StorageReplicatedMergeTree::executeLogEntry(DB::ReplicatedMergeTreeLogEntry&) @ 0x0000000015eba91b 20. /build/src/Storages/StorageReplicatedMergeTree.cpp:3876: bool std::__function::__policy_invoker&)>::__call_impl[abi:se190107])::$_1, bool (std::shared_ptr&)>>(std::__function::__policy_storage const*, std::shared_ptr&) @ 0x0000000015f9837e 21. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000165d6fc3 22. /build/src/Storages/StorageReplicatedMergeTree.cpp:3872: DB::StorageReplicatedMergeTree::processQueueEntry(std::shared_ptr) @ 0x0000000015efc18a 23. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001624c1b2 24. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000162f9c70 25. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x00000000162fa55a 26. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc6653 27. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000000fccc4c3 28. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc3d92 29. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fcca080 30. ? @ 0x00007fbc6213eac3 31. ? @ 0x00007fbc621d0850 (version 25.3.6.10636.altinitytest (altinity build)) 2025.07.28 11:54:46.617140 [ 17203 ] {1057db44-5975-420f-b3ea-600817e1bb4f} 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.6.10636.altinitytest (altinity build)) (from [::1]:56178) (comment: 00933_reserved_word.sql) (query 3, line 4) (in query: DETACH TABLE reserved_word_table;), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000000a074fcb 4. /build/src/Databases/DatabaseReplicated.cpp:1108: DB::DatabaseReplicated::checkQueryValid(std::shared_ptr const&, std::shared_ptr) const @ 0x0000000013d9ef48 5. /build/src/Databases/DatabaseReplicated.cpp:1130: DB::DatabaseReplicated::tryEnqueueReplicatedDDL(std::shared_ptr const&, std::shared_ptr, DB::QueryFlags) @ 0x0000000013d9f10b 6. /build/src/Interpreters/InterpreterDropQuery.cpp:226: DB::InterpreterDropQuery::executeToTableImpl(std::shared_ptr const&, DB::ASTDropQuery&, std::shared_ptr&, StrongTypedef, DB::UUIDTag>&) @ 0x0000000014914ed7 7. /build/src/Interpreters/InterpreterDropQuery.cpp:118: DB::InterpreterDropQuery::executeToTable(DB::ASTDropQuery&) @ 0x00000000149137b4 8. /build/src/Interpreters/InterpreterDropQuery.cpp:91: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000014912f07 9. /build/src/Interpreters/InterpreterDropQuery.cpp:72: DB::InterpreterDropQuery::execute() @ 0x0000000014912b65 10. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88dc9 11. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 12. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 13. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 14. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 15. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 16. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 17. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 18. ? @ 0x00007fbc6213eac3 19. ? @ 0x00007fbc621d0850 2025.07.28 11:54:46.633474 [ 17203 ] {} 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. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000000a074fcb 4. /build/src/Databases/DatabaseReplicated.cpp:1108: DB::DatabaseReplicated::checkQueryValid(std::shared_ptr const&, std::shared_ptr) const @ 0x0000000013d9ef48 5. /build/src/Databases/DatabaseReplicated.cpp:1130: DB::DatabaseReplicated::tryEnqueueReplicatedDDL(std::shared_ptr const&, std::shared_ptr, DB::QueryFlags) @ 0x0000000013d9f10b 6. /build/src/Interpreters/InterpreterDropQuery.cpp:226: DB::InterpreterDropQuery::executeToTableImpl(std::shared_ptr const&, DB::ASTDropQuery&, std::shared_ptr&, StrongTypedef, DB::UUIDTag>&) @ 0x0000000014914ed7 7. /build/src/Interpreters/InterpreterDropQuery.cpp:118: DB::InterpreterDropQuery::executeToTable(DB::ASTDropQuery&) @ 0x00000000149137b4 8. /build/src/Interpreters/InterpreterDropQuery.cpp:91: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000014912f07 9. /build/src/Interpreters/InterpreterDropQuery.cpp:72: DB::InterpreterDropQuery::execute() @ 0x0000000014912b65 10. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88dc9 11. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 12. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 13. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 14. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 15. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 16. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 17. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 18. ? @ 0x00007fbc6213eac3 19. ? @ 0x00007fbc621d0850 2025.07.28 11:54:46.752906 [ 3967 ] {} test_13.rmt2 (7f9b740d-015c-470e-8cc6-8ba33be0dc63): auto DB::StorageReplicatedMergeTree::processQueueEntry(ReplicatedMergeTreeQueue::SelectedEntryPtr)::(anonymous class)::operator()(LogEntryPtr &) const: Code: 86. DB::HTTPException: Received error from remote server http://146b4357c08d:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Ftest%2F01165%2Ftest_13%2Frmt%2Freplicas%2F1&part=20250728_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.6.10636.altinitytest (altinity build)) '. (RECEIVED_ERROR_FROM_REMOTE_IO_SERVER), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.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 const&, int&&, String const&, unsigned long&&, String const&) @ 0x000000000feda8d9 4. /build/src/IO/HTTPCommon.cpp:104: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x000000000feda6e2 5. /build/src/IO/HTTPCommon.cpp:93: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x000000000feda537 6. /build/src/IO/ReadWriteBufferFromHTTP.cpp:277: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x000000001184a4c4 7. /build/src/IO/ReadWriteBufferFromHTTP.cpp:285: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x000000001184a615 8. /build/src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x000000001184ae59 9. /build/src/IO/ReadWriteBufferFromHTTP.cpp:472: void std::__function::__policy_invoker::__call_impl[abi:se190107]>(std::__function::__policy_storage const*) @ 0x000000001184cedd 10. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001184858b 11. /build/src/IO/ReadWriteBufferFromHTTP.cpp:465: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x000000001184bf0b 12. /build/src/IO/ReadBuffer.h:60: DB::ReadBuffer::next() @ 0x000000000a148c7b 13. /build/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) @ 0x0000000011849fb2 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]>&)>&, 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&) @ 0x0000000011841980 15. /build/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) @ 0x000000001621208e 16. /build/src/Storages/StorageReplicatedMergeTree.cpp:5228: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl[abi:se190107] const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000015f9a5fe 17. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000015ed8bfd 18. /build/src/Storages/StorageReplicatedMergeTree.cpp:2514: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x0000000015ec9aab 19. /build/src/Storages/StorageReplicatedMergeTree.cpp:2349: DB::StorageReplicatedMergeTree::executeLogEntry(DB::ReplicatedMergeTreeLogEntry&) @ 0x0000000015eba91b 20. /build/src/Storages/StorageReplicatedMergeTree.cpp:3876: bool std::__function::__policy_invoker&)>::__call_impl[abi:se190107])::$_1, bool (std::shared_ptr&)>>(std::__function::__policy_storage const*, std::shared_ptr&) @ 0x0000000015f9837e 21. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000165d6fc3 22. /build/src/Storages/StorageReplicatedMergeTree.cpp:3872: DB::StorageReplicatedMergeTree::processQueueEntry(std::shared_ptr) @ 0x0000000015efc18a 23. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001624c1b2 24. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000162f9c70 25. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x00000000162fa55a 26. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc6653 27. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000000fccc4c3 28. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc3d92 29. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fcca080 30. ? @ 0x00007fbc6213eac3 31. ? @ 0x00007fbc621d0850 (version 25.3.6.10636.altinitytest (altinity build)) 2025.07.28 11:54:47.707357 [ 3964 ] {} test_13.rmt2 (7f9b740d-015c-470e-8cc6-8ba33be0dc63): auto DB::StorageReplicatedMergeTree::processQueueEntry(ReplicatedMergeTreeQueue::SelectedEntryPtr)::(anonymous class)::operator()(LogEntryPtr &) const: Code: 86. DB::HTTPException: Received error from remote server http://146b4357c08d:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Ftest%2F01165%2Ftest_13%2Frmt%2Freplicas%2F1&part=20250728_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.6.10636.altinitytest (altinity build)) '. (RECEIVED_ERROR_FROM_REMOTE_IO_SERVER), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.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 const&, int&&, String const&, unsigned long&&, String const&) @ 0x000000000feda8d9 4. /build/src/IO/HTTPCommon.cpp:104: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x000000000feda6e2 5. /build/src/IO/HTTPCommon.cpp:93: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x000000000feda537 6. /build/src/IO/ReadWriteBufferFromHTTP.cpp:277: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x000000001184a4c4 7. /build/src/IO/ReadWriteBufferFromHTTP.cpp:285: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x000000001184a615 8. /build/src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x000000001184ae59 9. /build/src/IO/ReadWriteBufferFromHTTP.cpp:472: void std::__function::__policy_invoker::__call_impl[abi:se190107]>(std::__function::__policy_storage const*) @ 0x000000001184cedd 10. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001184858b 11. /build/src/IO/ReadWriteBufferFromHTTP.cpp:465: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x000000001184bf0b 12. /build/src/IO/ReadBuffer.h:60: DB::ReadBuffer::next() @ 0x000000000a148c7b 13. /build/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) @ 0x0000000011849fb2 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]>&)>&, 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&) @ 0x0000000011841980 15. /build/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) @ 0x000000001621208e 16. /build/src/Storages/StorageReplicatedMergeTree.cpp:5228: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl[abi:se190107] const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000015f9a5fe 17. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000015ed8bfd 18. /build/src/Storages/StorageReplicatedMergeTree.cpp:2514: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x0000000015ec9aab 19. /build/src/Storages/StorageReplicatedMergeTree.cpp:2349: DB::StorageReplicatedMergeTree::executeLogEntry(DB::ReplicatedMergeTreeLogEntry&) @ 0x0000000015eba91b 20. /build/src/Storages/StorageReplicatedMergeTree.cpp:3876: bool std::__function::__policy_invoker&)>::__call_impl[abi:se190107])::$_1, bool (std::shared_ptr&)>>(std::__function::__policy_storage const*, std::shared_ptr&) @ 0x0000000015f9837e 21. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000165d6fc3 22. /build/src/Storages/StorageReplicatedMergeTree.cpp:3872: DB::StorageReplicatedMergeTree::processQueueEntry(std::shared_ptr) @ 0x0000000015efc18a 23. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001624c1b2 24. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000162f9c70 25. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x00000000162fa55a 26. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc6653 27. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000000fccc4c3 28. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc3d92 29. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fcca080 30. ? @ 0x00007fbc6213eac3 31. ? @ 0x00007fbc621d0850 (version 25.3.6.10636.altinitytest (altinity build)) 2025.07.28 11:54:47.756821 [ 17203 ] {caf80864-e5a5-4427-962f-c9df2041cc4d} PushingToViews: Failed to push block to view test_5.v2 (7c22a887-3ed3-40f1-a092-d92463e4b87b), Target table 'test_5.t2' of view 'test_5.v2' doesn't exists. To ignore this view use setting ignore_materialized_views_with_dropped_target_table 2025.07.28 11:54:47.811792 [ 17203 ] {caf80864-e5a5-4427-962f-c9df2041cc4d} executeQuery: Code: 60. DB::Exception: Target table 'test_5.t2' of view 'test_5.v2' doesn't exists. To ignore this view use setting ignore_materialized_views_with_dropped_target_table. (UNKNOWN_TABLE) (version 25.3.6.10636.altinitytest (altinity build)) (from [::1]:56188) (comment: 02023_nullable_int_uint_where.sql) (query 4, line 6) (in query: insert into t1 values ), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000a06a8eb 4. /build/src/Processors/Transforms/buildPushingToViewsChain.cpp:322: 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) @ 0x0000000016cb1bac 5. /build/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&) @ 0x0000000016cb34a8 6. /build/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*) @ 0x000000001492df0b 7. /build/src/Interpreters/InterpreterInsertQuery.cpp:503: DB::InterpreterInsertQuery::buildPreAndSinkChains(unsigned long, unsigned long, std::shared_ptr, unsigned long, std::shared_ptr const&, DB::Block const&) @ 0x000000001492f8f2 8. /build/src/Interpreters/InterpreterInsertQuery.cpp:755: DB::InterpreterInsertQuery::buildInsertPipeline(DB::ASTInsertQuery&, std::shared_ptr) @ 0x00000000149325d4 9. /build/src/Interpreters/InterpreterInsertQuery.cpp:875: DB::InterpreterInsertQuery::execute() @ 0x0000000014933db3 10. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88dc9 11. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 12. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 13. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 14. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 15. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 16. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 17. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 18. ? @ 0x00007fbc6213eac3 19. ? @ 0x00007fbc621d0850 2025.07.28 11:54:47.839693 [ 17203 ] {} TCPHandler: Code: 60. DB::Exception: Target table 'test_5.t2' of view 'test_5.v2' doesn't exists. To ignore this view use setting ignore_materialized_views_with_dropped_target_table. (UNKNOWN_TABLE), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000a06a8eb 4. /build/src/Processors/Transforms/buildPushingToViewsChain.cpp:322: 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) @ 0x0000000016cb1bac 5. /build/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&) @ 0x0000000016cb34a8 6. /build/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*) @ 0x000000001492df0b 7. /build/src/Interpreters/InterpreterInsertQuery.cpp:503: DB::InterpreterInsertQuery::buildPreAndSinkChains(unsigned long, unsigned long, std::shared_ptr, unsigned long, std::shared_ptr const&, DB::Block const&) @ 0x000000001492f8f2 8. /build/src/Interpreters/InterpreterInsertQuery.cpp:755: DB::InterpreterInsertQuery::buildInsertPipeline(DB::ASTInsertQuery&, std::shared_ptr) @ 0x00000000149325d4 9. /build/src/Interpreters/InterpreterInsertQuery.cpp:875: DB::InterpreterInsertQuery::execute() @ 0x0000000014933db3 10. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88dc9 11. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 12. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 13. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 14. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 15. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 16. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 17. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 18. ? @ 0x00007fbc6213eac3 19. ? @ 0x00007fbc621d0850 2025.07.28 11:54:47.904022 [ 3968 ] {} test_13.rmt2 (7f9b740d-015c-470e-8cc6-8ba33be0dc63): auto DB::StorageReplicatedMergeTree::processQueueEntry(ReplicatedMergeTreeQueue::SelectedEntryPtr)::(anonymous class)::operator()(LogEntryPtr &) const: Code: 86. DB::HTTPException: Received error from remote server http://146b4357c08d:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Ftest%2F01165%2Ftest_13%2Frmt%2Freplicas%2F1&part=20250728_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.6.10636.altinitytest (altinity build)) '. (RECEIVED_ERROR_FROM_REMOTE_IO_SERVER), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.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 const&, int&&, String const&, unsigned long&&, String const&) @ 0x000000000feda8d9 4. /build/src/IO/HTTPCommon.cpp:104: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x000000000feda6e2 5. /build/src/IO/HTTPCommon.cpp:93: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x000000000feda537 6. /build/src/IO/ReadWriteBufferFromHTTP.cpp:277: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x000000001184a4c4 7. /build/src/IO/ReadWriteBufferFromHTTP.cpp:285: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x000000001184a615 8. /build/src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x000000001184ae59 9. /build/src/IO/ReadWriteBufferFromHTTP.cpp:472: void std::__function::__policy_invoker::__call_impl[abi:se190107]>(std::__function::__policy_storage const*) @ 0x000000001184cedd 10. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001184858b 11. /build/src/IO/ReadWriteBufferFromHTTP.cpp:465: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x000000001184bf0b 12. /build/src/IO/ReadBuffer.h:60: DB::ReadBuffer::next() @ 0x000000000a148c7b 13. /build/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) @ 0x0000000011849fb2 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]>&)>&, 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&) @ 0x0000000011841980 15. /build/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) @ 0x000000001621208e 16. /build/src/Storages/StorageReplicatedMergeTree.cpp:5228: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl[abi:se190107] const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000015f9a5fe 17. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000015ed8bfd 18. /build/src/Storages/StorageReplicatedMergeTree.cpp:2514: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x0000000015ec9aab 19. /build/src/Storages/StorageReplicatedMergeTree.cpp:2349: DB::StorageReplicatedMergeTree::executeLogEntry(DB::ReplicatedMergeTreeLogEntry&) @ 0x0000000015eba91b 20. /build/src/Storages/StorageReplicatedMergeTree.cpp:3876: bool std::__function::__policy_invoker&)>::__call_impl[abi:se190107])::$_1, bool (std::shared_ptr&)>>(std::__function::__policy_storage const*, std::shared_ptr&) @ 0x0000000015f9837e 21. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000165d6fc3 22. /build/src/Storages/StorageReplicatedMergeTree.cpp:3872: DB::StorageReplicatedMergeTree::processQueueEntry(std::shared_ptr) @ 0x0000000015efc18a 23. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001624c1b2 24. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000162f9c70 25. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x00000000162fa55a 26. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc6653 27. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000000fccc4c3 28. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc3d92 29. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fcca080 30. ? @ 0x00007fbc6213eac3 31. ? @ 0x00007fbc621d0850 (version 25.3.6.10636.altinitytest (altinity build)) 2025.07.28 11:54:48.953095 [ 3962 ] {} test_13.rmt2 (7f9b740d-015c-470e-8cc6-8ba33be0dc63): auto DB::StorageReplicatedMergeTree::processQueueEntry(ReplicatedMergeTreeQueue::SelectedEntryPtr)::(anonymous class)::operator()(LogEntryPtr &) const: Code: 86. DB::HTTPException: Received error from remote server http://146b4357c08d:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Ftest%2F01165%2Ftest_13%2Frmt%2Freplicas%2F1&part=20250728_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.6.10636.altinitytest (altinity build)) '. (RECEIVED_ERROR_FROM_REMOTE_IO_SERVER), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.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 const&, int&&, String const&, unsigned long&&, String const&) @ 0x000000000feda8d9 4. /build/src/IO/HTTPCommon.cpp:104: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x000000000feda6e2 5. /build/src/IO/HTTPCommon.cpp:93: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x000000000feda537 6. /build/src/IO/ReadWriteBufferFromHTTP.cpp:277: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x000000001184a4c4 7. /build/src/IO/ReadWriteBufferFromHTTP.cpp:285: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x000000001184a615 8. /build/src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x000000001184ae59 9. /build/src/IO/ReadWriteBufferFromHTTP.cpp:472: void std::__function::__policy_invoker::__call_impl[abi:se190107]>(std::__function::__policy_storage const*) @ 0x000000001184cedd 10. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001184858b 11. /build/src/IO/ReadWriteBufferFromHTTP.cpp:465: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x000000001184bf0b 12. /build/src/IO/ReadBuffer.h:60: DB::ReadBuffer::next() @ 0x000000000a148c7b 13. /build/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) @ 0x0000000011849fb2 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]>&)>&, 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&) @ 0x0000000011841980 15. /build/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) @ 0x000000001621208e 16. /build/src/Storages/StorageReplicatedMergeTree.cpp:5228: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl[abi:se190107] const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000015f9a5fe 17. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000015ed8bfd 18. /build/src/Storages/StorageReplicatedMergeTree.cpp:2514: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x0000000015ec9aab 19. /build/src/Storages/StorageReplicatedMergeTree.cpp:2349: DB::StorageReplicatedMergeTree::executeLogEntry(DB::ReplicatedMergeTreeLogEntry&) @ 0x0000000015eba91b 20. /build/src/Storages/StorageReplicatedMergeTree.cpp:3876: bool std::__function::__policy_invoker&)>::__call_impl[abi:se190107])::$_1, bool (std::shared_ptr&)>>(std::__function::__policy_storage const*, std::shared_ptr&) @ 0x0000000015f9837e 21. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000165d6fc3 22. /build/src/Storages/StorageReplicatedMergeTree.cpp:3872: DB::StorageReplicatedMergeTree::processQueueEntry(std::shared_ptr) @ 0x0000000015efc18a 23. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001624c1b2 24. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000162f9c70 25. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x00000000162fa55a 26. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc6653 27. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000000fccc4c3 28. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc3d92 29. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fcca080 30. ? @ 0x00007fbc6213eac3 31. ? @ 0x00007fbc621d0850 (version 25.3.6.10636.altinitytest (altinity build)) 2025.07.28 11:54:49.443808 [ 17191 ] {2bab2e3c-c195-4593-8355-eb350138de6b} executeQuery: Code: 57. DB::Exception: Table test_5.t already exists. (TABLE_ALREADY_EXISTS) (version 25.3.6.10636.altinitytest (altinity build)) (from 0.0.0.0:0) (comment: 01907_multiple_aliases.sql) (in query: /* ddl_entry=query-0000000095 */ CREATE TABLE test_5.t UUID 'b4809dce-35c1-4ede-a71f-0158a858ac8a' (`d` Date, `z` UInt32) ENGINE = MergeTree(d, z, 1)), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000a06a8eb 4. /build/src/Interpreters/InterpreterCreateQuery.cpp:1824: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x0000000014901d53 5. /build/src/Interpreters/InterpreterCreateQuery.cpp:1743: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000148f9aa9 6. /build/src/Interpreters/InterpreterCreateQuery.cpp:2352: DB::InterpreterCreateQuery::execute() @ 0x0000000014905a41 7. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88dc9 8. /build/src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x0000000014c8ca7b 9. /build/src/Interpreters/DDLWorker.cpp:510: DB::DDLWorker::tryExecuteQuery(DB::DDLTaskBase&, std::shared_ptr const&, bool) @ 0x00000000144dab9e 10. /build/src/Interpreters/DDLWorker.cpp:675: DB::DDLWorker::processTask(DB::DDLTaskBase&, std::shared_ptr const&, bool) @ 0x00000000144d8ffe 11. /build/src/Databases/DatabaseReplicatedWorker.cpp:372: DB::DatabaseReplicatedDDLWorker::tryEnqueueAndExecuteEntry(DB::DDLLogEntry&, std::shared_ptr, bool) @ 0x0000000013dc29ab 12. /build/src/Databases/DatabaseReplicated.cpp:1139: DB::DatabaseReplicated::tryEnqueueReplicatedDDL(std::shared_ptr const&, std::shared_ptr, DB::QueryFlags) @ 0x0000000013d9f73c 13. /build/src/Interpreters/InterpreterCreateQuery.cpp:1723: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000148f96f8 14. /build/src/Interpreters/InterpreterCreateQuery.cpp:2352: DB::InterpreterCreateQuery::execute() @ 0x0000000014905a41 15. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88dc9 16. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 17. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 18. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 19. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 20. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 21. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 22. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 23. ? @ 0x00007fbc6213eac3 24. ? @ 0x00007fbc621d0850 2025.07.28 11:54:49.492752 [ 17191 ] {2bab2e3c-c195-4593-8355-eb350138de6b} executeQuery: Code: 57. DB::Exception: Table test_5.t already exists. (TABLE_ALREADY_EXISTS) (version 25.3.6.10636.altinitytest (altinity build)) (from [::1]:56290) (comment: 01907_multiple_aliases.sql) (query 3, line 3) (in query: CREATE TABLE t (d Date, z UInt32) ENGINE = MergeTree(d, (z), 1);), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000a06a8eb 4. /build/src/Interpreters/InterpreterCreateQuery.cpp:1824: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x0000000014901d53 5. /build/src/Interpreters/InterpreterCreateQuery.cpp:1743: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000148f9aa9 6. /build/src/Interpreters/InterpreterCreateQuery.cpp:2352: DB::InterpreterCreateQuery::execute() @ 0x0000000014905a41 7. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88dc9 8. /build/src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x0000000014c8ca7b 9. /build/src/Interpreters/DDLWorker.cpp:510: DB::DDLWorker::tryExecuteQuery(DB::DDLTaskBase&, std::shared_ptr const&, bool) @ 0x00000000144dab9e 10. /build/src/Interpreters/DDLWorker.cpp:675: DB::DDLWorker::processTask(DB::DDLTaskBase&, std::shared_ptr const&, bool) @ 0x00000000144d8ffe 11. /build/src/Databases/DatabaseReplicatedWorker.cpp:372: DB::DatabaseReplicatedDDLWorker::tryEnqueueAndExecuteEntry(DB::DDLLogEntry&, std::shared_ptr, bool) @ 0x0000000013dc29ab 12. /build/src/Databases/DatabaseReplicated.cpp:1139: DB::DatabaseReplicated::tryEnqueueReplicatedDDL(std::shared_ptr const&, std::shared_ptr, DB::QueryFlags) @ 0x0000000013d9f73c 13. /build/src/Interpreters/InterpreterCreateQuery.cpp:1723: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000148f96f8 14. /build/src/Interpreters/InterpreterCreateQuery.cpp:2352: DB::InterpreterCreateQuery::execute() @ 0x0000000014905a41 15. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88dc9 16. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 17. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 18. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 19. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 20. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 21. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 22. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 23. ? @ 0x00007fbc6213eac3 24. ? @ 0x00007fbc621d0850 2025.07.28 11:54:49.523950 [ 17191 ] {} 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. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000a06a8eb 4. /build/src/Interpreters/InterpreterCreateQuery.cpp:1824: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x0000000014901d53 5. /build/src/Interpreters/InterpreterCreateQuery.cpp:1743: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000148f9aa9 6. /build/src/Interpreters/InterpreterCreateQuery.cpp:2352: DB::InterpreterCreateQuery::execute() @ 0x0000000014905a41 7. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88dc9 8. /build/src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x0000000014c8ca7b 9. /build/src/Interpreters/DDLWorker.cpp:510: DB::DDLWorker::tryExecuteQuery(DB::DDLTaskBase&, std::shared_ptr const&, bool) @ 0x00000000144dab9e 10. /build/src/Interpreters/DDLWorker.cpp:675: DB::DDLWorker::processTask(DB::DDLTaskBase&, std::shared_ptr const&, bool) @ 0x00000000144d8ffe 11. /build/src/Databases/DatabaseReplicatedWorker.cpp:372: DB::DatabaseReplicatedDDLWorker::tryEnqueueAndExecuteEntry(DB::DDLLogEntry&, std::shared_ptr, bool) @ 0x0000000013dc29ab 12. /build/src/Databases/DatabaseReplicated.cpp:1139: DB::DatabaseReplicated::tryEnqueueReplicatedDDL(std::shared_ptr const&, std::shared_ptr, DB::QueryFlags) @ 0x0000000013d9f73c 13. /build/src/Interpreters/InterpreterCreateQuery.cpp:1723: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000148f96f8 14. /build/src/Interpreters/InterpreterCreateQuery.cpp:2352: DB::InterpreterCreateQuery::execute() @ 0x0000000014905a41 15. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88dc9 16. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 17. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 18. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 19. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 20. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 21. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 22. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 23. ? @ 0x00007fbc6213eac3 24. ? @ 0x00007fbc621d0850 2025.07.28 11:54:49.847063 [ 3960 ] {} test_13.rmt2 (7f9b740d-015c-470e-8cc6-8ba33be0dc63): auto DB::StorageReplicatedMergeTree::processQueueEntry(ReplicatedMergeTreeQueue::SelectedEntryPtr)::(anonymous class)::operator()(LogEntryPtr &) const: Code: 86. DB::HTTPException: Received error from remote server http://146b4357c08d:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Ftest%2F01165%2Ftest_13%2Frmt%2Freplicas%2F1&part=20250728_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.6.10636.altinitytest (altinity build)) '. (RECEIVED_ERROR_FROM_REMOTE_IO_SERVER), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.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 const&, int&&, String const&, unsigned long&&, String const&) @ 0x000000000feda8d9 4. /build/src/IO/HTTPCommon.cpp:104: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x000000000feda6e2 5. /build/src/IO/HTTPCommon.cpp:93: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x000000000feda537 6. /build/src/IO/ReadWriteBufferFromHTTP.cpp:277: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x000000001184a4c4 7. /build/src/IO/ReadWriteBufferFromHTTP.cpp:285: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x000000001184a615 8. /build/src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x000000001184ae59 9. /build/src/IO/ReadWriteBufferFromHTTP.cpp:472: void std::__function::__policy_invoker::__call_impl[abi:se190107]>(std::__function::__policy_storage const*) @ 0x000000001184cedd 10. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001184858b 11. /build/src/IO/ReadWriteBufferFromHTTP.cpp:465: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x000000001184bf0b 12. /build/src/IO/ReadBuffer.h:60: DB::ReadBuffer::next() @ 0x000000000a148c7b 13. /build/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) @ 0x0000000011849fb2 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]>&)>&, 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&) @ 0x0000000011841980 15. /build/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) @ 0x000000001621208e 16. /build/src/Storages/StorageReplicatedMergeTree.cpp:5228: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl[abi:se190107] const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000015f9a5fe 17. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000015ed8bfd 18. /build/src/Storages/StorageReplicatedMergeTree.cpp:2514: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x0000000015ec9aab 19. /build/src/Storages/StorageReplicatedMergeTree.cpp:2349: DB::StorageReplicatedMergeTree::executeLogEntry(DB::ReplicatedMergeTreeLogEntry&) @ 0x0000000015eba91b 20. /build/src/Storages/StorageReplicatedMergeTree.cpp:3876: bool std::__function::__policy_invoker&)>::__call_impl[abi:se190107])::$_1, bool (std::shared_ptr&)>>(std::__function::__policy_storage const*, std::shared_ptr&) @ 0x0000000015f9837e 21. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000165d6fc3 22. /build/src/Storages/StorageReplicatedMergeTree.cpp:3872: DB::StorageReplicatedMergeTree::processQueueEntry(std::shared_ptr) @ 0x0000000015efc18a 23. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001624c1b2 24. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000162f9c70 25. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x00000000162fa55a 26. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc6653 27. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000000fccc4c3 28. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc3d92 29. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fcca080 30. ? @ 0x00007fbc6213eac3 31. ? @ 0x00007fbc621d0850 (version 25.3.6.10636.altinitytest (altinity build)) 2025.07.28 11:54:49.884876 [ 17203 ] {1230e410-c2cf-4052-a336-46cb679504f4} executeQuery: Code: 215. DB::Exception: Column c is not under aggregate function and not in GROUP BY keys. In query SELECT a, sum(b) FROM (SELECT 1 AS a, 1 AS b, 0 AS c) GROUP BY a HAVING c SETTINGS enable_analyzer = 1. (NOT_AN_AGGREGATE) (version 25.3.6.10636.altinitytest (altinity build)) (from [::1]:56320) (comment: 02701_invalid_having_NOT_AN_AGGREGATE.sql) (query 1, line 1) (in query: SELECT a, sum(b) FROM (SELECT 1 AS a, 1 AS b, 0 AS c) GROUP BY a HAVING c SETTINGS enable_analyzer=1 -- { serverError NOT_AN_AGGREGATE } ), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000a06a8eb 4. /build/src/Analyzer/ValidationUtils.cpp:199: DB::InDepthQueryTreeVisitor::visit(std::shared_ptr const&) @ 0x00000000140680c9 5. /build/src/Analyzer/ValidationUtils.cpp:348: DB::validateAggregates(std::shared_ptr const&, DB::AggregatesValidationParams) @ 0x000000001406727f 6. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5774: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000014014827 7. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000140127f9 8. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000014011fce 9. /build/src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000001406ce8a 10. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000014973b42 11. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000001497268d 12. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000014974d24 13. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001492924b 14. /build/src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88641 15. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 16. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 17. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 18. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 19. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 20. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 21. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 22. ? @ 0x00007fbc6213eac3 23. ? @ 0x00007fbc621d0850 2025.07.28 11:54:49.890247 [ 17203 ] {} TCPHandler: Code: 215. DB::Exception: Column c is not under aggregate function and not in GROUP BY keys. In query SELECT a, sum(b) FROM (SELECT 1 AS a, 1 AS b, 0 AS c) GROUP BY a HAVING c SETTINGS enable_analyzer = 1. (NOT_AN_AGGREGATE), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000a06a8eb 4. /build/src/Analyzer/ValidationUtils.cpp:199: DB::InDepthQueryTreeVisitor::visit(std::shared_ptr const&) @ 0x00000000140680c9 5. /build/src/Analyzer/ValidationUtils.cpp:348: DB::validateAggregates(std::shared_ptr const&, DB::AggregatesValidationParams) @ 0x000000001406727f 6. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5774: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000014014827 7. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000140127f9 8. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000014011fce 9. /build/src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000001406ce8a 10. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000014973b42 11. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000001497268d 12. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000014974d24 13. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001492924b 14. /build/src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88641 15. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 16. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 17. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 18. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 19. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 20. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 21. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 22. ? @ 0x00007fbc6213eac3 23. ? @ 0x00007fbc621d0850 2025.07.28 11:54:50.447468 [ 3972 ] {} test_13.rmt2 (7f9b740d-015c-470e-8cc6-8ba33be0dc63): auto DB::StorageReplicatedMergeTree::processQueueEntry(ReplicatedMergeTreeQueue::SelectedEntryPtr)::(anonymous class)::operator()(LogEntryPtr &) const: Code: 86. DB::HTTPException: Received error from remote server http://146b4357c08d:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Ftest%2F01165%2Ftest_13%2Frmt%2Freplicas%2F1&part=20250728_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.6.10636.altinitytest (altinity build)) '. (RECEIVED_ERROR_FROM_REMOTE_IO_SERVER), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.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 const&, int&&, String const&, unsigned long&&, String const&) @ 0x000000000feda8d9 4. /build/src/IO/HTTPCommon.cpp:104: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x000000000feda6e2 5. /build/src/IO/HTTPCommon.cpp:93: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x000000000feda537 6. /build/src/IO/ReadWriteBufferFromHTTP.cpp:277: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x000000001184a4c4 7. /build/src/IO/ReadWriteBufferFromHTTP.cpp:285: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x000000001184a615 8. /build/src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x000000001184ae59 9. /build/src/IO/ReadWriteBufferFromHTTP.cpp:472: void std::__function::__policy_invoker::__call_impl[abi:se190107]>(std::__function::__policy_storage const*) @ 0x000000001184cedd 10. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001184858b 11. /build/src/IO/ReadWriteBufferFromHTTP.cpp:465: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x000000001184bf0b 12. /build/src/IO/ReadBuffer.h:60: DB::ReadBuffer::next() @ 0x000000000a148c7b 13. /build/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) @ 0x0000000011849fb2 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]>&)>&, 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&) @ 0x0000000011841980 15. /build/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) @ 0x000000001621208e 16. /build/src/Storages/StorageReplicatedMergeTree.cpp:5228: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl[abi:se190107] const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000015f9a5fe 17. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000015ed8bfd 18. /build/src/Storages/StorageReplicatedMergeTree.cpp:2514: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x0000000015ec9aab 19. /build/src/Storages/StorageReplicatedMergeTree.cpp:2349: DB::StorageReplicatedMergeTree::executeLogEntry(DB::ReplicatedMergeTreeLogEntry&) @ 0x0000000015eba91b 20. /build/src/Storages/StorageReplicatedMergeTree.cpp:3876: bool std::__function::__policy_invoker&)>::__call_impl[abi:se190107])::$_1, bool (std::shared_ptr&)>>(std::__function::__policy_storage const*, std::shared_ptr&) @ 0x0000000015f9837e 21. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000165d6fc3 22. /build/src/Storages/StorageReplicatedMergeTree.cpp:3872: DB::StorageReplicatedMergeTree::processQueueEntry(std::shared_ptr) @ 0x0000000015efc18a 23. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001624c1b2 24. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000162f9c70 25. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x00000000162fa55a 26. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc6653 27. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000000fccc4c3 28. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc3d92 29. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fcca080 30. ? @ 0x00007fbc6213eac3 31. ? @ 0x00007fbc621d0850 (version 25.3.6.10636.altinitytest (altinity build)) 2025.07.28 11:54:50.533712 [ 17191 ] {} 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. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception>&, String>(int, FormatStringHelperImpl>&>::type, std::type_identity::type>, std::basic_string_view>&, String&&) @ 0x000000001385a5eb 4. /build/src/Access/SettingsConstraints.cpp:376: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000013859b18 5. /build/src/Access/SettingsConstraints.cpp:300: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000013858faf 6. /build/src/Access/SettingsConstraints.cpp:209: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000013859223 7. /build/src/Interpreters/Context.cpp:2690: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000014436134 8. /build/src/Interpreters/Context.cpp:2729: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x000000001443662b 9. /build/src/Server/HTTPHandler.cpp:457: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000001686d165 10. /build/src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x0000000016870807 11. /build/src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x0000000016907e99 12. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 13. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 14. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 15. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 16. ? @ 0x00007fbc6213eac3 17. ? @ 0x00007fbc621d0850 (version 25.3.6.10636.altinitytest (altinity build)) 2025.07.28 11:54:51.125355 [ 3968 ] {} test_13.rmt2 (7f9b740d-015c-470e-8cc6-8ba33be0dc63): auto DB::StorageReplicatedMergeTree::processQueueEntry(ReplicatedMergeTreeQueue::SelectedEntryPtr)::(anonymous class)::operator()(LogEntryPtr &) const: Code: 86. DB::HTTPException: Received error from remote server http://146b4357c08d:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Ftest%2F01165%2Ftest_13%2Frmt%2Freplicas%2F1&part=20250728_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.6.10636.altinitytest (altinity build)) '. (RECEIVED_ERROR_FROM_REMOTE_IO_SERVER), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.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 const&, int&&, String const&, unsigned long&&, String const&) @ 0x000000000feda8d9 4. /build/src/IO/HTTPCommon.cpp:104: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x000000000feda6e2 5. /build/src/IO/HTTPCommon.cpp:93: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x000000000feda537 6. /build/src/IO/ReadWriteBufferFromHTTP.cpp:277: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x000000001184a4c4 7. /build/src/IO/ReadWriteBufferFromHTTP.cpp:285: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x000000001184a615 8. /build/src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x000000001184ae59 9. /build/src/IO/ReadWriteBufferFromHTTP.cpp:472: void std::__function::__policy_invoker::__call_impl[abi:se190107]>(std::__function::__policy_storage const*) @ 0x000000001184cedd 10. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001184858b 11. /build/src/IO/ReadWriteBufferFromHTTP.cpp:465: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x000000001184bf0b 12. /build/src/IO/ReadBuffer.h:60: DB::ReadBuffer::next() @ 0x000000000a148c7b 13. /build/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) @ 0x0000000011849fb2 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]>&)>&, 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&) @ 0x0000000011841980 15. /build/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) @ 0x000000001621208e 16. /build/src/Storages/StorageReplicatedMergeTree.cpp:5228: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl[abi:se190107] const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000015f9a5fe 17. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000015ed8bfd 18. /build/src/Storages/StorageReplicatedMergeTree.cpp:2514: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x0000000015ec9aab 19. /build/src/Storages/StorageReplicatedMergeTree.cpp:2349: DB::StorageReplicatedMergeTree::executeLogEntry(DB::ReplicatedMergeTreeLogEntry&) @ 0x0000000015eba91b 20. /build/src/Storages/StorageReplicatedMergeTree.cpp:3876: bool std::__function::__policy_invoker&)>::__call_impl[abi:se190107])::$_1, bool (std::shared_ptr&)>>(std::__function::__policy_storage const*, std::shared_ptr&) @ 0x0000000015f9837e 21. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000165d6fc3 22. /build/src/Storages/StorageReplicatedMergeTree.cpp:3872: DB::StorageReplicatedMergeTree::processQueueEntry(std::shared_ptr) @ 0x0000000015efc18a 23. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001624c1b2 24. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000162f9c70 25. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x00000000162fa55a 26. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc6653 27. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000000fccc4c3 28. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc3d92 29. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fcca080 30. ? @ 0x00007fbc6213eac3 31. ? @ 0x00007fbc621d0850 (version 25.3.6.10636.altinitytest (altinity build)) 2025.07.28 11:54:51.901841 [ 3965 ] {} test_13.rmt2 (7f9b740d-015c-470e-8cc6-8ba33be0dc63): auto DB::StorageReplicatedMergeTree::processQueueEntry(ReplicatedMergeTreeQueue::SelectedEntryPtr)::(anonymous class)::operator()(LogEntryPtr &) const: Code: 86. DB::HTTPException: Received error from remote server http://146b4357c08d:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Ftest%2F01165%2Ftest_13%2Frmt%2Freplicas%2F1&part=20250728_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.6.10636.altinitytest (altinity build)) '. (RECEIVED_ERROR_FROM_REMOTE_IO_SERVER), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.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 const&, int&&, String const&, unsigned long&&, String const&) @ 0x000000000feda8d9 4. /build/src/IO/HTTPCommon.cpp:104: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x000000000feda6e2 5. /build/src/IO/HTTPCommon.cpp:93: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x000000000feda537 6. /build/src/IO/ReadWriteBufferFromHTTP.cpp:277: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x000000001184a4c4 7. /build/src/IO/ReadWriteBufferFromHTTP.cpp:285: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x000000001184a615 8. /build/src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x000000001184ae59 9. /build/src/IO/ReadWriteBufferFromHTTP.cpp:472: void std::__function::__policy_invoker::__call_impl[abi:se190107]>(std::__function::__policy_storage const*) @ 0x000000001184cedd 10. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001184858b 11. /build/src/IO/ReadWriteBufferFromHTTP.cpp:465: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x000000001184bf0b 12. /build/src/IO/ReadBuffer.h:60: DB::ReadBuffer::next() @ 0x000000000a148c7b 13. /build/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) @ 0x0000000011849fb2 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]>&)>&, 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&) @ 0x0000000011841980 15. /build/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) @ 0x000000001621208e 16. /build/src/Storages/StorageReplicatedMergeTree.cpp:5228: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl[abi:se190107] const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000015f9a5fe 17. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000015ed8bfd 18. /build/src/Storages/StorageReplicatedMergeTree.cpp:2514: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x0000000015ec9aab 19. /build/src/Storages/StorageReplicatedMergeTree.cpp:2349: DB::StorageReplicatedMergeTree::executeLogEntry(DB::ReplicatedMergeTreeLogEntry&) @ 0x0000000015eba91b 20. /build/src/Storages/StorageReplicatedMergeTree.cpp:3876: bool std::__function::__policy_invoker&)>::__call_impl[abi:se190107])::$_1, bool (std::shared_ptr&)>>(std::__function::__policy_storage const*, std::shared_ptr&) @ 0x0000000015f9837e 21. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000165d6fc3 22. /build/src/Storages/StorageReplicatedMergeTree.cpp:3872: DB::StorageReplicatedMergeTree::processQueueEntry(std::shared_ptr) @ 0x0000000015efc18a 23. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001624c1b2 24. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000162f9c70 25. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x00000000162fa55a 26. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc6653 27. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000000fccc4c3 28. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc3d92 29. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fcca080 30. ? @ 0x00007fbc6213eac3 31. ? @ 0x00007fbc621d0850 (version 25.3.6.10636.altinitytest (altinity build)) 2025.07.28 11:54:52.922117 [ 3962 ] {} test_13.rmt2 (7f9b740d-015c-470e-8cc6-8ba33be0dc63): auto DB::StorageReplicatedMergeTree::processQueueEntry(ReplicatedMergeTreeQueue::SelectedEntryPtr)::(anonymous class)::operator()(LogEntryPtr &) const: Code: 86. DB::HTTPException: Received error from remote server http://146b4357c08d:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Ftest%2F01165%2Ftest_13%2Frmt%2Freplicas%2F1&part=20250728_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.6.10636.altinitytest (altinity build)) '. (RECEIVED_ERROR_FROM_REMOTE_IO_SERVER), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.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 const&, int&&, String const&, unsigned long&&, String const&) @ 0x000000000feda8d9 4. /build/src/IO/HTTPCommon.cpp:104: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x000000000feda6e2 5. /build/src/IO/HTTPCommon.cpp:93: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x000000000feda537 6. /build/src/IO/ReadWriteBufferFromHTTP.cpp:277: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x000000001184a4c4 7. /build/src/IO/ReadWriteBufferFromHTTP.cpp:285: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x000000001184a615 8. /build/src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x000000001184ae59 9. /build/src/IO/ReadWriteBufferFromHTTP.cpp:472: void std::__function::__policy_invoker::__call_impl[abi:se190107]>(std::__function::__policy_storage const*) @ 0x000000001184cedd 10. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001184858b 11. /build/src/IO/ReadWriteBufferFromHTTP.cpp:465: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x000000001184bf0b 12. /build/src/IO/ReadBuffer.h:60: DB::ReadBuffer::next() @ 0x000000000a148c7b 13. /build/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) @ 0x0000000011849fb2 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]>&)>&, 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&) @ 0x0000000011841980 15. /build/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) @ 0x000000001621208e 16. /build/src/Storages/StorageReplicatedMergeTree.cpp:5228: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl[abi:se190107] const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000015f9a5fe 17. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000015ed8bfd 18. /build/src/Storages/StorageReplicatedMergeTree.cpp:2514: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x0000000015ec9aab 19. /build/src/Storages/StorageReplicatedMergeTree.cpp:2349: DB::StorageReplicatedMergeTree::executeLogEntry(DB::ReplicatedMergeTreeLogEntry&) @ 0x0000000015eba91b 20. /build/src/Storages/StorageReplicatedMergeTree.cpp:3876: bool std::__function::__policy_invoker&)>::__call_impl[abi:se190107])::$_1, bool (std::shared_ptr&)>>(std::__function::__policy_storage const*, std::shared_ptr&) @ 0x0000000015f9837e 21. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000165d6fc3 22. /build/src/Storages/StorageReplicatedMergeTree.cpp:3872: DB::StorageReplicatedMergeTree::processQueueEntry(std::shared_ptr) @ 0x0000000015efc18a 23. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001624c1b2 24. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000162f9c70 25. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x00000000162fa55a 26. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc6653 27. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000000fccc4c3 28. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc3d92 29. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fcca080 30. ? @ 0x00007fbc6213eac3 31. ? @ 0x00007fbc621d0850 (version 25.3.6.10636.altinitytest (altinity build)) 2025.07.28 11:54:53.705215 [ 17255 ] {ec58241c-c715-4d4f-98de-54f57d7fc4a6} executeQuery: Code: 47. DB::Exception: Unknown expression or table expression identifier `some_identifier` in scope (_CAST(NULL, 'Nullable(Nothing)'), _CAST(NULL, 'Nullable(Nothing)'), 0) GLOBAL IN (some_identifier). (UNKNOWN_IDENTIFIER) (version 25.3.6.10636.altinitytest (altinity build)) (from [::1]:52396) (comment: 02002_global_subqueries_subquery_or_table_name.sql) (query 1, line 3) (in query: SELECT cityHash64(number GLOBAL IN (NULL, -2147483648, -9223372036854775808), nan, 1024, NULL, NULL, 1.000100016593933, NULL), (NULL, cityHash64(inf, -2147483648, NULL, NULL, 10.000100135803223), cityHash64(1.1754943508222875e-38, NULL, NULL, NULL), 2147483647) FROM cluster(test_cluster_two_shards_localhost, numbers((NULL, cityHash64(0., 65536, NULL, NULL, 10000000000., NULL), 0) GLOBAL IN (some_identifier), 65536)) WHERE number GLOBAL IN [1025] --{ serverError BAD_ARGUMENTS, WRONG_GLOBAL_SUBQUERY, UNKNOWN_IDENTIFIER } ), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.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&&) @ 0x000000001404b3b9 4. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3771: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000001401b849 5. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3980: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000014018e31 6. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:2925: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000001402fcbd 7. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3838: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000014019a9e 8. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:254: DB::QueryAnalyzer::resolveConstantExpression(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000001401fd4b 9. /build/src/Interpreters/evaluateConstantExpression.cpp:115: DB::evaluateConstantExpressionImpl(std::shared_ptr const&, std::shared_ptr const&, bool) @ 0x0000000014c67ee1 10. /build/src/Interpreters/evaluateConstantExpression.cpp:196: DB::evaluateConstantExpression(std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000014c69cb9 11. /build/src/TableFunctions/TableFunctionNumbers.cpp:102: DB::(anonymous namespace)::TableFunctionNumbers::evaluateArgument(std::shared_ptr, std::shared_ptr&) const @ 0x00000000118106b3 12. /build/src/TableFunctions/TableFunctionNumbers.cpp:79: DB::(anonymous namespace)::TableFunctionNumbers::executeImpl(std::shared_ptr const&, std::shared_ptr, String const&, DB::ColumnsDescription, bool) const @ 0x00000000118100cf 13. /build/src/TableFunctions/ITableFunction.cpp:36: DB::ITableFunction::execute(std::shared_ptr const&, std::shared_ptr, String const&, DB::ColumnsDescription, bool, bool) const @ 0x00000000131e9fc3 14. /build/src/Interpreters/Context.cpp:2501: DB::Context::executeTableFunction(std::shared_ptr const&, std::shared_ptr const&) @ 0x00000000144345b2 15. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:4975: DB::QueryAnalyzer::resolveTableFunction(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&, bool) @ 0x000000001401e9f9 16. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:4791: DB::QueryAnalyzer::resolveTableFunction(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&, bool) @ 0x000000001401c4f9 17. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5342: DB::QueryAnalyzer::resolveQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&) @ 0x00000000140452bf 18. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5597: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000140136f0 19. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000140127f9 20. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000014011fce 21. /build/src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000001406ce8a 22. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000014973b42 23. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000001497268d 24. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000014974d24 25. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001492924b 26. /build/src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88641 27. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 28. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 29. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 30. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 31. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 2025.07.28 11:54:53.711477 [ 17255 ] {} TCPHandler: Code: 47. DB::Exception: Unknown expression or table expression identifier `some_identifier` in scope (_CAST(NULL, 'Nullable(Nothing)'), _CAST(NULL, 'Nullable(Nothing)'), 0) GLOBAL IN (some_identifier). (UNKNOWN_IDENTIFIER), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.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&&) @ 0x000000001404b3b9 4. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3771: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000001401b849 5. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3980: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000014018e31 6. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:2925: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000001402fcbd 7. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3838: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000014019a9e 8. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:254: DB::QueryAnalyzer::resolveConstantExpression(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x000000001401fd4b 9. /build/src/Interpreters/evaluateConstantExpression.cpp:115: DB::evaluateConstantExpressionImpl(std::shared_ptr const&, std::shared_ptr const&, bool) @ 0x0000000014c67ee1 10. /build/src/Interpreters/evaluateConstantExpression.cpp:196: DB::evaluateConstantExpression(std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000014c69cb9 11. /build/src/TableFunctions/TableFunctionNumbers.cpp:102: DB::(anonymous namespace)::TableFunctionNumbers::evaluateArgument(std::shared_ptr, std::shared_ptr&) const @ 0x00000000118106b3 12. /build/src/TableFunctions/TableFunctionNumbers.cpp:79: DB::(anonymous namespace)::TableFunctionNumbers::executeImpl(std::shared_ptr const&, std::shared_ptr, String const&, DB::ColumnsDescription, bool) const @ 0x00000000118100cf 13. /build/src/TableFunctions/ITableFunction.cpp:36: DB::ITableFunction::execute(std::shared_ptr const&, std::shared_ptr, String const&, DB::ColumnsDescription, bool, bool) const @ 0x00000000131e9fc3 14. /build/src/Interpreters/Context.cpp:2501: DB::Context::executeTableFunction(std::shared_ptr const&, std::shared_ptr const&) @ 0x00000000144345b2 15. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:4975: DB::QueryAnalyzer::resolveTableFunction(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&, bool) @ 0x000000001401e9f9 16. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:4791: DB::QueryAnalyzer::resolveTableFunction(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&, bool) @ 0x000000001401c4f9 17. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5342: DB::QueryAnalyzer::resolveQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&) @ 0x00000000140452bf 18. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5597: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000140136f0 19. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000140127f9 20. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000014011fce 21. /build/src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000001406ce8a 22. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000014973b42 23. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000001497268d 24. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000014974d24 25. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001492924b 26. /build/src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88641 27. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 28. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 29. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 30. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 31. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 2025.07.28 11:54:53.848975 [ 3977 ] {} test_13.rmt2 (7f9b740d-015c-470e-8cc6-8ba33be0dc63): auto DB::StorageReplicatedMergeTree::processQueueEntry(ReplicatedMergeTreeQueue::SelectedEntryPtr)::(anonymous class)::operator()(LogEntryPtr &) const: Code: 86. DB::HTTPException: Received error from remote server http://146b4357c08d:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Ftest%2F01165%2Ftest_13%2Frmt%2Freplicas%2F1&part=20250728_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.6.10636.altinitytest (altinity build)) '. (RECEIVED_ERROR_FROM_REMOTE_IO_SERVER), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.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 const&, int&&, String const&, unsigned long&&, String const&) @ 0x000000000feda8d9 4. /build/src/IO/HTTPCommon.cpp:104: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x000000000feda6e2 5. /build/src/IO/HTTPCommon.cpp:93: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x000000000feda537 6. /build/src/IO/ReadWriteBufferFromHTTP.cpp:277: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x000000001184a4c4 7. /build/src/IO/ReadWriteBufferFromHTTP.cpp:285: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x000000001184a615 8. /build/src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x000000001184ae59 9. /build/src/IO/ReadWriteBufferFromHTTP.cpp:472: void std::__function::__policy_invoker::__call_impl[abi:se190107]>(std::__function::__policy_storage const*) @ 0x000000001184cedd 10. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001184858b 11. /build/src/IO/ReadWriteBufferFromHTTP.cpp:465: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x000000001184bf0b 12. /build/src/IO/ReadBuffer.h:60: DB::ReadBuffer::next() @ 0x000000000a148c7b 13. /build/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) @ 0x0000000011849fb2 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]>&)>&, 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&) @ 0x0000000011841980 15. /build/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) @ 0x000000001621208e 16. /build/src/Storages/StorageReplicatedMergeTree.cpp:5228: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl[abi:se190107] const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000015f9a5fe 17. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000015ed8bfd 18. /build/src/Storages/StorageReplicatedMergeTree.cpp:2514: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x0000000015ec9aab 19. /build/src/Storages/StorageReplicatedMergeTree.cpp:2349: DB::StorageReplicatedMergeTree::executeLogEntry(DB::ReplicatedMergeTreeLogEntry&) @ 0x0000000015eba91b 20. /build/src/Storages/StorageReplicatedMergeTree.cpp:3876: bool std::__function::__policy_invoker&)>::__call_impl[abi:se190107])::$_1, bool (std::shared_ptr&)>>(std::__function::__policy_storage const*, std::shared_ptr&) @ 0x0000000015f9837e 21. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000165d6fc3 22. /build/src/Storages/StorageReplicatedMergeTree.cpp:3872: DB::StorageReplicatedMergeTree::processQueueEntry(std::shared_ptr) @ 0x0000000015efc18a 23. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001624c1b2 24. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000162f9c70 25. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x00000000162fa55a 26. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc6653 27. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000000fccc4c3 28. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc3d92 29. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fcca080 30. ? @ 0x00007fbc6213eac3 31. ? @ 0x00007fbc621d0850 (version 25.3.6.10636.altinitytest (altinity build)) 2025.07.28 11:54:54.166458 [ 17208 ] {} 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. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception>&, String>(int, FormatStringHelperImpl>&>::type, std::type_identity::type>, std::basic_string_view>&, String&&) @ 0x000000001385a5eb 4. /build/src/Access/SettingsConstraints.cpp:376: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000013859b18 5. /build/src/Access/SettingsConstraints.cpp:300: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000013858faf 6. /build/src/Access/SettingsConstraints.cpp:209: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000013859223 7. /build/src/Interpreters/Context.cpp:2690: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000014436134 8. /build/src/Interpreters/Context.cpp:2729: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x000000001443662b 9. /build/src/Server/HTTPHandler.cpp:457: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000001686d165 10. /build/src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x0000000016870807 11. /build/src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x0000000016907e99 12. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 13. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 14. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 15. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 16. ? @ 0x00007fbc6213eac3 17. ? @ 0x00007fbc621d0850 (version 25.3.6.10636.altinitytest (altinity build)) 2025.07.28 11:54:54.711212 [ 3967 ] {} test_13.rmt2 (7f9b740d-015c-470e-8cc6-8ba33be0dc63): auto DB::StorageReplicatedMergeTree::processQueueEntry(ReplicatedMergeTreeQueue::SelectedEntryPtr)::(anonymous class)::operator()(LogEntryPtr &) const: Code: 86. DB::HTTPException: Received error from remote server http://146b4357c08d:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Ftest%2F01165%2Ftest_13%2Frmt%2Freplicas%2F1&part=20250728_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.6.10636.altinitytest (altinity build)) '. (RECEIVED_ERROR_FROM_REMOTE_IO_SERVER), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.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 const&, int&&, String const&, unsigned long&&, String const&) @ 0x000000000feda8d9 4. /build/src/IO/HTTPCommon.cpp:104: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x000000000feda6e2 5. /build/src/IO/HTTPCommon.cpp:93: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x000000000feda537 6. /build/src/IO/ReadWriteBufferFromHTTP.cpp:277: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x000000001184a4c4 7. /build/src/IO/ReadWriteBufferFromHTTP.cpp:285: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x000000001184a615 8. /build/src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x000000001184ae59 9. /build/src/IO/ReadWriteBufferFromHTTP.cpp:472: void std::__function::__policy_invoker::__call_impl[abi:se190107]>(std::__function::__policy_storage const*) @ 0x000000001184cedd 10. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001184858b 11. /build/src/IO/ReadWriteBufferFromHTTP.cpp:465: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x000000001184bf0b 12. /build/src/IO/ReadBuffer.h:60: DB::ReadBuffer::next() @ 0x000000000a148c7b 13. /build/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) @ 0x0000000011849fb2 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]>&)>&, 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&) @ 0x0000000011841980 15. /build/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) @ 0x000000001621208e 16. /build/src/Storages/StorageReplicatedMergeTree.cpp:5228: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl[abi:se190107] const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000015f9a5fe 17. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000015ed8bfd 18. /build/src/Storages/StorageReplicatedMergeTree.cpp:2514: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x0000000015ec9aab 19. /build/src/Storages/StorageReplicatedMergeTree.cpp:2349: DB::StorageReplicatedMergeTree::executeLogEntry(DB::ReplicatedMergeTreeLogEntry&) @ 0x0000000015eba91b 20. /build/src/Storages/StorageReplicatedMergeTree.cpp:3876: bool std::__function::__policy_invoker&)>::__call_impl[abi:se190107])::$_1, bool (std::shared_ptr&)>>(std::__function::__policy_storage const*, std::shared_ptr&) @ 0x0000000015f9837e 21. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000165d6fc3 22. /build/src/Storages/StorageReplicatedMergeTree.cpp:3872: DB::StorageReplicatedMergeTree::processQueueEntry(std::shared_ptr) @ 0x0000000015efc18a 23. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001624c1b2 24. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000162f9c70 25. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x00000000162fa55a 26. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc6653 27. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000000fccc4c3 28. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc3d92 29. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fcca080 30. ? @ 0x00007fbc6213eac3 31. ? @ 0x00007fbc621d0850 (version 25.3.6.10636.altinitytest (altinity build)) 2025.07.28 11:54:55.232545 [ 17255 ] {59caa8af-770a-48f0-890e-8a1c744d1f8a} executeQuery: Code: 43. DB::Exception: Illegal type AggregateFunction(quantile, UInt8) of argument for aggregate function sum: In scope SELECT toTypeName(initializeAggregation('sumState', initializeAggregation('quantileState', 0))). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.6.10636.altinitytest (altinity build)) (from [::1]:52416) (comment: 01890_state_of_state.sql) (query 10, line 10) (in query: SELECT toTypeName(initializeAggregation('sumState', initializeAggregation('quantileState', 0)));), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String const&) @ 0x000000000a68756b 4. /build/src/AggregateFunctions/AggregateFunctionSum.cpp:66: std::shared_ptr DB::(anonymous namespace)::createAggregateFunctionSum(String const&, std::vector, std::allocator>> const&, DB::Array const&, DB::Settings const*) @ 0x0000000010de8997 5. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000131e00dd 6. /build/src/AggregateFunctions/AggregateFunctionFactory.cpp:130: DB::AggregateFunctionFactory::get(String const&, DB::NullsAction, std::vector, std::allocator>> const&, DB::Array const&, DB::AggregateFunctionProperties&) const @ 0x00000000131df0ca 7. /build/src/AggregateFunctions/AggregateFunctionFactory.cpp:253: DB::AggregateFunctionFactory::getImpl(String const&, DB::NullsAction, std::vector, std::allocator>> const&, DB::Array const&, DB::AggregateFunctionProperties&, bool) const @ 0x00000000131e004b 8. /build/src/AggregateFunctions/AggregateFunctionFactory.cpp:130: DB::AggregateFunctionFactory::get(String const&, DB::NullsAction, std::vector, std::allocator>> const&, DB::Array const&, DB::AggregateFunctionProperties&) const @ 0x00000000131df0ca 9. /build/src/Functions/initializeAggregation.cpp:88: DB::(anonymous namespace)::FunctionInitializeAggregation::getReturnTypeImpl(std::vector> const&) const @ 0x000000000c27ba2c 10. /build/src/Functions/IFunction.cpp:645: DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x0000000012d96b0c 11. /build/src/Functions/IFunction.cpp:577: DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x0000000012d9669c 12. /build/src/Functions/IFunction.cpp:606: DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x0000000012d96edc 13. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3544: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000014033cc9 14. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3838: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000014019a9e 15. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3980: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000014018e31 16. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:2925: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000001402fcbd 17. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3838: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000014019a9e 18. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3980: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000014018e31 19. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:4304: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000014042fa7 20. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5605: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000014013749 21. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000140127f9 22. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000014011fce 23. /build/src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000001406ce8a 24. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000014973b42 25. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000001497268d 26. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000014974d24 27. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001492924b 28. /build/src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88641 29. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 30. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 31. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 2025.07.28 11:54:55.259515 [ 17255 ] {} TCPHandler: Code: 43. DB::Exception: Illegal type AggregateFunction(quantile, UInt8) of argument for aggregate function sum: In scope SELECT toTypeName(initializeAggregation('sumState', initializeAggregation('quantileState', 0))). (ILLEGAL_TYPE_OF_ARGUMENT), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String const&) @ 0x000000000a68756b 4. /build/src/AggregateFunctions/AggregateFunctionSum.cpp:66: std::shared_ptr DB::(anonymous namespace)::createAggregateFunctionSum(String const&, std::vector, std::allocator>> const&, DB::Array const&, DB::Settings const*) @ 0x0000000010de8997 5. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000131e00dd 6. /build/src/AggregateFunctions/AggregateFunctionFactory.cpp:130: DB::AggregateFunctionFactory::get(String const&, DB::NullsAction, std::vector, std::allocator>> const&, DB::Array const&, DB::AggregateFunctionProperties&) const @ 0x00000000131df0ca 7. /build/src/AggregateFunctions/AggregateFunctionFactory.cpp:253: DB::AggregateFunctionFactory::getImpl(String const&, DB::NullsAction, std::vector, std::allocator>> const&, DB::Array const&, DB::AggregateFunctionProperties&, bool) const @ 0x00000000131e004b 8. /build/src/AggregateFunctions/AggregateFunctionFactory.cpp:130: DB::AggregateFunctionFactory::get(String const&, DB::NullsAction, std::vector, std::allocator>> const&, DB::Array const&, DB::AggregateFunctionProperties&) const @ 0x00000000131df0ca 9. /build/src/Functions/initializeAggregation.cpp:88: DB::(anonymous namespace)::FunctionInitializeAggregation::getReturnTypeImpl(std::vector> const&) const @ 0x000000000c27ba2c 10. /build/src/Functions/IFunction.cpp:645: DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x0000000012d96b0c 11. /build/src/Functions/IFunction.cpp:577: DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x0000000012d9669c 12. /build/src/Functions/IFunction.cpp:606: DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x0000000012d96edc 13. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3544: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000014033cc9 14. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3838: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000014019a9e 15. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3980: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000014018e31 16. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:2925: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000001402fcbd 17. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3838: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000014019a9e 18. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3980: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000014018e31 19. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:4304: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000014042fa7 20. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5605: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000014013749 21. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000140127f9 22. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000014011fce 23. /build/src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000001406ce8a 24. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000014973b42 25. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000001497268d 26. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000014974d24 27. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001492924b 28. /build/src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88641 29. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 30. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 31. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 2025.07.28 11:54:55.778356 [ 3969 ] {} test_13.rmt2 (7f9b740d-015c-470e-8cc6-8ba33be0dc63): auto DB::StorageReplicatedMergeTree::processQueueEntry(ReplicatedMergeTreeQueue::SelectedEntryPtr)::(anonymous class)::operator()(LogEntryPtr &) const: Code: 86. DB::HTTPException: Received error from remote server http://146b4357c08d:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Ftest%2F01165%2Ftest_13%2Frmt%2Freplicas%2F1&part=20250728_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.6.10636.altinitytest (altinity build)) '. (RECEIVED_ERROR_FROM_REMOTE_IO_SERVER), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.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 const&, int&&, String const&, unsigned long&&, String const&) @ 0x000000000feda8d9 4. /build/src/IO/HTTPCommon.cpp:104: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x000000000feda6e2 5. /build/src/IO/HTTPCommon.cpp:93: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x000000000feda537 6. /build/src/IO/ReadWriteBufferFromHTTP.cpp:277: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x000000001184a4c4 7. /build/src/IO/ReadWriteBufferFromHTTP.cpp:285: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x000000001184a615 8. /build/src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x000000001184ae59 9. /build/src/IO/ReadWriteBufferFromHTTP.cpp:472: void std::__function::__policy_invoker::__call_impl[abi:se190107]>(std::__function::__policy_storage const*) @ 0x000000001184cedd 10. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001184858b 11. /build/src/IO/ReadWriteBufferFromHTTP.cpp:465: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x000000001184bf0b 12. /build/src/IO/ReadBuffer.h:60: DB::ReadBuffer::next() @ 0x000000000a148c7b 13. /build/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) @ 0x0000000011849fb2 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]>&)>&, 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&) @ 0x0000000011841980 15. /build/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) @ 0x000000001621208e 16. /build/src/Storages/StorageReplicatedMergeTree.cpp:5228: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl[abi:se190107] const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000015f9a5fe 17. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000015ed8bfd 18. /build/src/Storages/StorageReplicatedMergeTree.cpp:2514: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x0000000015ec9aab 19. /build/src/Storages/StorageReplicatedMergeTree.cpp:2349: DB::StorageReplicatedMergeTree::executeLogEntry(DB::ReplicatedMergeTreeLogEntry&) @ 0x0000000015eba91b 20. /build/src/Storages/StorageReplicatedMergeTree.cpp:3876: bool std::__function::__policy_invoker&)>::__call_impl[abi:se190107])::$_1, bool (std::shared_ptr&)>>(std::__function::__policy_storage const*, std::shared_ptr&) @ 0x0000000015f9837e 21. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000165d6fc3 22. /build/src/Storages/StorageReplicatedMergeTree.cpp:3872: DB::StorageReplicatedMergeTree::processQueueEntry(std::shared_ptr) @ 0x0000000015efc18a 23. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001624c1b2 24. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000162f9c70 25. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x00000000162fa55a 26. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc6653 27. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000000fccc4c3 28. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc3d92 29. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fcca080 30. ? @ 0x00007fbc6213eac3 31. ? @ 0x00007fbc621d0850 (version 25.3.6.10636.altinitytest (altinity build)) 2025.07.28 11:54:56.254512 [ 17255 ] {d33d240c-e6b2-4026-9b6f-b0f6fc2f8fd1} executeQuery: Code: 43. DB::Exception: Illegal type AggregateFunction(uniq, UInt8) of argument of aggregate function max because the values of that data type are not comparable: In scope SELECT hex(toString(initializeAggregation('maxState', initializeAggregation('uniqState', 0)))). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.6.10636.altinitytest (altinity build)) (from [::1]:52416) (comment: 01890_state_of_state.sql) (query 17, line 17) (in query: SELECT hex(toString(initializeAggregation('maxState', initializeAggregation('uniqState', 0))));), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000a06a8eb 4. /build/src/AggregateFunctions/AggregateFunctionsMinMax.cpp:33: DB::IAggregateFunction* DB::createAggregateFunctionSingleValue(String const&, std::vector, std::allocator>> const&, DB::Array const&, DB::Settings const*) @ 0x00000000109e0288 5. /build/src/AggregateFunctions/AggregateFunctionsMinMax.cpp:200: std::shared_ptr DB::(anonymous namespace)::createAggregateFunctionMinMax(String const&, std::vector, std::allocator>> const&, DB::Array const&, DB::Settings const*) @ 0x00000000109c0009 6. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000131e00dd 7. /build/src/AggregateFunctions/AggregateFunctionFactory.cpp:130: DB::AggregateFunctionFactory::get(String const&, DB::NullsAction, std::vector, std::allocator>> const&, DB::Array const&, DB::AggregateFunctionProperties&) const @ 0x00000000131df0ca 8. /build/src/AggregateFunctions/AggregateFunctionFactory.cpp:253: DB::AggregateFunctionFactory::getImpl(String const&, DB::NullsAction, std::vector, std::allocator>> const&, DB::Array const&, DB::AggregateFunctionProperties&, bool) const @ 0x00000000131e004b 9. /build/src/AggregateFunctions/AggregateFunctionFactory.cpp:130: DB::AggregateFunctionFactory::get(String const&, DB::NullsAction, std::vector, std::allocator>> const&, DB::Array const&, DB::AggregateFunctionProperties&) const @ 0x00000000131df0ca 10. /build/src/Functions/initializeAggregation.cpp:88: DB::(anonymous namespace)::FunctionInitializeAggregation::getReturnTypeImpl(std::vector> const&) const @ 0x000000000c27ba2c 11. /build/src/Functions/IFunction.cpp:645: DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x0000000012d96b0c 12. /build/src/Functions/IFunction.cpp:577: DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x0000000012d9669c 13. /build/src/Functions/IFunction.cpp:606: DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x0000000012d96edc 14. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3544: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000014033cc9 15. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3838: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000014019a9e 16. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3980: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000014018e31 17. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:2925: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000001402fcbd 18. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3838: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000014019a9e 19. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3980: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000014018e31 20. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:2925: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000001402fcbd 21. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3838: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000014019a9e 22. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3980: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000014018e31 23. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:4304: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000014042fa7 24. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5605: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000014013749 25. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000140127f9 26. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000014011fce 27. /build/src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000001406ce8a 28. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000014973b42 29. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000001497268d 30. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000014974d24 31. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001492924b 2025.07.28 11:54:56.258231 [ 17255 ] {} TCPHandler: Code: 43. DB::Exception: Illegal type AggregateFunction(uniq, UInt8) of argument of aggregate function max because the values of that data type are not comparable: In scope SELECT hex(toString(initializeAggregation('maxState', initializeAggregation('uniqState', 0)))). (ILLEGAL_TYPE_OF_ARGUMENT), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000a06a8eb 4. /build/src/AggregateFunctions/AggregateFunctionsMinMax.cpp:33: DB::IAggregateFunction* DB::createAggregateFunctionSingleValue(String const&, std::vector, std::allocator>> const&, DB::Array const&, DB::Settings const*) @ 0x00000000109e0288 5. /build/src/AggregateFunctions/AggregateFunctionsMinMax.cpp:200: std::shared_ptr DB::(anonymous namespace)::createAggregateFunctionMinMax(String const&, std::vector, std::allocator>> const&, DB::Array const&, DB::Settings const*) @ 0x00000000109c0009 6. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000131e00dd 7. /build/src/AggregateFunctions/AggregateFunctionFactory.cpp:130: DB::AggregateFunctionFactory::get(String const&, DB::NullsAction, std::vector, std::allocator>> const&, DB::Array const&, DB::AggregateFunctionProperties&) const @ 0x00000000131df0ca 8. /build/src/AggregateFunctions/AggregateFunctionFactory.cpp:253: DB::AggregateFunctionFactory::getImpl(String const&, DB::NullsAction, std::vector, std::allocator>> const&, DB::Array const&, DB::AggregateFunctionProperties&, bool) const @ 0x00000000131e004b 9. /build/src/AggregateFunctions/AggregateFunctionFactory.cpp:130: DB::AggregateFunctionFactory::get(String const&, DB::NullsAction, std::vector, std::allocator>> const&, DB::Array const&, DB::AggregateFunctionProperties&) const @ 0x00000000131df0ca 10. /build/src/Functions/initializeAggregation.cpp:88: DB::(anonymous namespace)::FunctionInitializeAggregation::getReturnTypeImpl(std::vector> const&) const @ 0x000000000c27ba2c 11. /build/src/Functions/IFunction.cpp:645: DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x0000000012d96b0c 12. /build/src/Functions/IFunction.cpp:577: DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x0000000012d9669c 13. /build/src/Functions/IFunction.cpp:606: DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x0000000012d96edc 14. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3544: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000014033cc9 15. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3838: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000014019a9e 16. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3980: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000014018e31 17. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:2925: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000001402fcbd 18. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3838: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000014019a9e 19. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3980: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000014018e31 20. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:2925: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000001402fcbd 21. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3838: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000014019a9e 22. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3980: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000014018e31 23. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:4304: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000014042fa7 24. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5605: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000014013749 25. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000140127f9 26. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000014011fce 27. /build/src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000001406ce8a 28. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000014973b42 29. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000001497268d 30. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000014974d24 31. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001492924b 2025.07.28 11:54:56.508066 [ 17255 ] {9634dcc2-40e2-43fa-97fb-76630d0d362c} executeQuery: Code: 43. DB::Exception: Illegal type AggregateFunction(uniq, UInt64) of argument for aggregate function quantile. (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.6.10636.altinitytest (altinity build)) (from [::1]:52416) (comment: 01890_state_of_state.sql) (query 20, line 20) (in query: SELECT toTypeName(quantileState(x)) FROM (SELECT uniqState(number) AS x FROM numbers(1000));), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String const&) @ 0x000000000a68756b 4. /build/src/AggregateFunctions/AggregateFunctionQuantile.cpp:144: std::shared_ptr DB::(anonymous namespace)::createAggregateFunctionQuantile(String const&, std::vector, std::allocator>> const&, DB::Array const&, DB::Settings const*) @ 0x0000000010316a91 5. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000131e00dd 6. /build/src/AggregateFunctions/AggregateFunctionFactory.cpp:130: DB::AggregateFunctionFactory::get(String const&, DB::NullsAction, std::vector, std::allocator>> const&, DB::Array const&, DB::AggregateFunctionProperties&) const @ 0x00000000131df0ca 7. /build/src/AggregateFunctions/AggregateFunctionFactory.cpp:253: DB::AggregateFunctionFactory::getImpl(String const&, DB::NullsAction, std::vector, std::allocator>> const&, DB::Array const&, DB::AggregateFunctionProperties&, bool) const @ 0x00000000131e004b 8. /build/src/AggregateFunctions/AggregateFunctionFactory.cpp:130: DB::AggregateFunctionFactory::get(String const&, DB::NullsAction, std::vector, std::allocator>> const&, DB::Array const&, DB::AggregateFunctionProperties&) const @ 0x00000000131df0ca 9. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3368: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000014032fed 10. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3838: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000014019a9e 11. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3980: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000014018e31 12. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:2925: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000001402fcbd 13. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3838: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000014019a9e 14. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3980: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000014018e31 15. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:4304: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000014042fa7 16. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5605: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000014013749 17. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000140127f9 18. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000014011fce 19. /build/src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000001406ce8a 20. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000014973b42 21. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000001497268d 22. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000014974d24 23. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001492924b 24. /build/src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88641 25. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 26. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 27. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 28. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 29. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 30. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 31. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 2025.07.28 11:54:56.513141 [ 17255 ] {} TCPHandler: Code: 43. DB::Exception: Illegal type AggregateFunction(uniq, UInt64) of argument for aggregate function quantile. (ILLEGAL_TYPE_OF_ARGUMENT), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String const&) @ 0x000000000a68756b 4. /build/src/AggregateFunctions/AggregateFunctionQuantile.cpp:144: std::shared_ptr DB::(anonymous namespace)::createAggregateFunctionQuantile(String const&, std::vector, std::allocator>> const&, DB::Array const&, DB::Settings const*) @ 0x0000000010316a91 5. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000131e00dd 6. /build/src/AggregateFunctions/AggregateFunctionFactory.cpp:130: DB::AggregateFunctionFactory::get(String const&, DB::NullsAction, std::vector, std::allocator>> const&, DB::Array const&, DB::AggregateFunctionProperties&) const @ 0x00000000131df0ca 7. /build/src/AggregateFunctions/AggregateFunctionFactory.cpp:253: DB::AggregateFunctionFactory::getImpl(String const&, DB::NullsAction, std::vector, std::allocator>> const&, DB::Array const&, DB::AggregateFunctionProperties&, bool) const @ 0x00000000131e004b 8. /build/src/AggregateFunctions/AggregateFunctionFactory.cpp:130: DB::AggregateFunctionFactory::get(String const&, DB::NullsAction, std::vector, std::allocator>> const&, DB::Array const&, DB::AggregateFunctionProperties&) const @ 0x00000000131df0ca 9. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3368: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000014032fed 10. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3838: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000014019a9e 11. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3980: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000014018e31 12. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:2925: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000001402fcbd 13. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3838: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000014019a9e 14. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3980: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000014018e31 15. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:4304: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000014042fa7 16. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5605: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000014013749 17. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000140127f9 18. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000014011fce 19. /build/src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000001406ce8a 20. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000014973b42 21. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000001497268d 22. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000014974d24 23. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001492924b 24. /build/src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88641 25. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 26. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 27. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 28. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 29. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 30. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 31. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 2025.07.28 11:54:56.554707 [ 3971 ] {} test_13.rmt2 (7f9b740d-015c-470e-8cc6-8ba33be0dc63): auto DB::StorageReplicatedMergeTree::processQueueEntry(ReplicatedMergeTreeQueue::SelectedEntryPtr)::(anonymous class)::operator()(LogEntryPtr &) const: Code: 86. DB::HTTPException: Received error from remote server http://146b4357c08d:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Ftest%2F01165%2Ftest_13%2Frmt%2Freplicas%2F1&part=20250728_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.6.10636.altinitytest (altinity build)) '. (RECEIVED_ERROR_FROM_REMOTE_IO_SERVER), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.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 const&, int&&, String const&, unsigned long&&, String const&) @ 0x000000000feda8d9 4. /build/src/IO/HTTPCommon.cpp:104: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x000000000feda6e2 5. /build/src/IO/HTTPCommon.cpp:93: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x000000000feda537 6. /build/src/IO/ReadWriteBufferFromHTTP.cpp:277: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x000000001184a4c4 7. /build/src/IO/ReadWriteBufferFromHTTP.cpp:285: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x000000001184a615 8. /build/src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x000000001184ae59 9. /build/src/IO/ReadWriteBufferFromHTTP.cpp:472: void std::__function::__policy_invoker::__call_impl[abi:se190107]>(std::__function::__policy_storage const*) @ 0x000000001184cedd 10. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001184858b 11. /build/src/IO/ReadWriteBufferFromHTTP.cpp:465: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x000000001184bf0b 12. /build/src/IO/ReadBuffer.h:60: DB::ReadBuffer::next() @ 0x000000000a148c7b 13. /build/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) @ 0x0000000011849fb2 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]>&)>&, 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&) @ 0x0000000011841980 15. /build/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) @ 0x000000001621208e 16. /build/src/Storages/StorageReplicatedMergeTree.cpp:5228: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl[abi:se190107] const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000015f9a5fe 17. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000015ed8bfd 18. /build/src/Storages/StorageReplicatedMergeTree.cpp:2514: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x0000000015ec9aab 19. /build/src/Storages/StorageReplicatedMergeTree.cpp:2349: DB::StorageReplicatedMergeTree::executeLogEntry(DB::ReplicatedMergeTreeLogEntry&) @ 0x0000000015eba91b 20. /build/src/Storages/StorageReplicatedMergeTree.cpp:3876: bool std::__function::__policy_invoker&)>::__call_impl[abi:se190107])::$_1, bool (std::shared_ptr&)>>(std::__function::__policy_storage const*, std::shared_ptr&) @ 0x0000000015f9837e 21. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000165d6fc3 22. /build/src/Storages/StorageReplicatedMergeTree.cpp:3872: DB::StorageReplicatedMergeTree::processQueueEntry(std::shared_ptr) @ 0x0000000015efc18a 23. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001624c1b2 24. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000162f9c70 25. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x00000000162fa55a 26. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc6653 27. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000000fccc4c3 28. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc3d92 29. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fcca080 30. ? @ 0x00007fbc6213eac3 31. ? @ 0x00007fbc621d0850 (version 25.3.6.10636.altinitytest (altinity build)) 2025.07.28 11:54:56.574820 [ 17255 ] {b1ed419c-0484-4e03-b917-700b1e6e0d8d} executeQuery: Code: 43. DB::Exception: Illegal type AggregateFunction(uniq, UInt64) of argument for aggregate function quantile. (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.6.10636.altinitytest (altinity build)) (from [::1]:52416) (comment: 01890_state_of_state.sql) (query 21, line 21) (in query: SELECT hex(toString(quantileState(x))) FROM (SELECT uniqState(number) AS x FROM numbers(1000));), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String const&) @ 0x000000000a68756b 4. /build/src/AggregateFunctions/AggregateFunctionQuantile.cpp:144: std::shared_ptr DB::(anonymous namespace)::createAggregateFunctionQuantile(String const&, std::vector, std::allocator>> const&, DB::Array const&, DB::Settings const*) @ 0x0000000010316a91 5. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000131e00dd 6. /build/src/AggregateFunctions/AggregateFunctionFactory.cpp:130: DB::AggregateFunctionFactory::get(String const&, DB::NullsAction, std::vector, std::allocator>> const&, DB::Array const&, DB::AggregateFunctionProperties&) const @ 0x00000000131df0ca 7. /build/src/AggregateFunctions/AggregateFunctionFactory.cpp:253: DB::AggregateFunctionFactory::getImpl(String const&, DB::NullsAction, std::vector, std::allocator>> const&, DB::Array const&, DB::AggregateFunctionProperties&, bool) const @ 0x00000000131e004b 8. /build/src/AggregateFunctions/AggregateFunctionFactory.cpp:130: DB::AggregateFunctionFactory::get(String const&, DB::NullsAction, std::vector, std::allocator>> const&, DB::Array const&, DB::AggregateFunctionProperties&) const @ 0x00000000131df0ca 9. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3368: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000014032fed 10. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3838: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000014019a9e 11. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3980: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000014018e31 12. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:2925: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000001402fcbd 13. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3838: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000014019a9e 14. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3980: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000014018e31 15. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:2925: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000001402fcbd 16. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3838: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000014019a9e 17. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3980: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000014018e31 18. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:4304: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000014042fa7 19. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5605: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000014013749 20. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000140127f9 21. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000014011fce 22. /build/src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000001406ce8a 23. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000014973b42 24. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000001497268d 25. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000014974d24 26. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001492924b 27. /build/src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88641 28. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 29. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 30. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 31. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 2025.07.28 11:54:56.577772 [ 17255 ] {} TCPHandler: Code: 43. DB::Exception: Illegal type AggregateFunction(uniq, UInt64) of argument for aggregate function quantile. (ILLEGAL_TYPE_OF_ARGUMENT), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String const&) @ 0x000000000a68756b 4. /build/src/AggregateFunctions/AggregateFunctionQuantile.cpp:144: std::shared_ptr DB::(anonymous namespace)::createAggregateFunctionQuantile(String const&, std::vector, std::allocator>> const&, DB::Array const&, DB::Settings const*) @ 0x0000000010316a91 5. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000131e00dd 6. /build/src/AggregateFunctions/AggregateFunctionFactory.cpp:130: DB::AggregateFunctionFactory::get(String const&, DB::NullsAction, std::vector, std::allocator>> const&, DB::Array const&, DB::AggregateFunctionProperties&) const @ 0x00000000131df0ca 7. /build/src/AggregateFunctions/AggregateFunctionFactory.cpp:253: DB::AggregateFunctionFactory::getImpl(String const&, DB::NullsAction, std::vector, std::allocator>> const&, DB::Array const&, DB::AggregateFunctionProperties&, bool) const @ 0x00000000131e004b 8. /build/src/AggregateFunctions/AggregateFunctionFactory.cpp:130: DB::AggregateFunctionFactory::get(String const&, DB::NullsAction, std::vector, std::allocator>> const&, DB::Array const&, DB::AggregateFunctionProperties&) const @ 0x00000000131df0ca 9. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3368: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000014032fed 10. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3838: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000014019a9e 11. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3980: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000014018e31 12. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:2925: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000001402fcbd 13. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3838: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000014019a9e 14. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3980: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000014018e31 15. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:2925: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000001402fcbd 16. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3838: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000014019a9e 17. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3980: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000014018e31 18. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:4304: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000014042fa7 19. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5605: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000014013749 20. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000140127f9 21. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000014011fce 22. /build/src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000001406ce8a 23. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000014973b42 24. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000001497268d 25. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000014974d24 26. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001492924b 27. /build/src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88641 28. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 29. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 30. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 31. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 2025.07.28 11:54:57.293257 [ 17243 ] {2883c40f-b426-4d2d-95c8-e190e251e2c3} executeQuery: Code: 219. DB::Exception: New table appeared in database being dropped or detached. Try again. (DATABASE_NOT_EMPTY) (version 25.3.6.10636.altinitytest (altinity build)) (from [::1]:54512) (comment: 03267_materialized_view_keeps_security_context.sql) (in query: DROP DATABASE IF EXISTS test_auik66wh SYNC ), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000000a074fcb 4. /build/src/Interpreters/DatabaseCatalog.cpp:608: DB::DatabaseCatalog::detachDatabase(std::shared_ptr, String const&, bool, bool) @ 0x00000000144f41b9 5. /build/src/Interpreters/InterpreterDropQuery.cpp:482: DB::InterpreterDropQuery::executeToDatabaseImpl(DB::ASTDropQuery const&, std::shared_ptr&, std::vector, DB::UUIDTag>, std::allocator, DB::UUIDTag>>>&) @ 0x00000000149179be 6. /build/src/Interpreters/InterpreterDropQuery.cpp:363: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x0000000014913988 7. /build/src/Interpreters/InterpreterDropQuery.cpp:99: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000014913142 8. /build/src/Interpreters/InterpreterDropQuery.cpp:72: DB::InterpreterDropQuery::execute() @ 0x0000000014912b65 9. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88dc9 10. /build/src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x0000000014c8ca7b 11. /build/src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000001686da12 12. /build/src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x0000000016870807 13. /build/src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x0000000016907e99 14. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 15. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 16. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 17. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 18. ? @ 0x00007fbc6213eac3 19. ? @ 0x00007fbc621d0850 2025.07.28 11:54:57.296364 [ 17243 ] {2883c40f-b426-4d2d-95c8-e190e251e2c3} 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. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000000a074fcb 4. /build/src/Interpreters/DatabaseCatalog.cpp:608: DB::DatabaseCatalog::detachDatabase(std::shared_ptr, String const&, bool, bool) @ 0x00000000144f41b9 5. /build/src/Interpreters/InterpreterDropQuery.cpp:482: DB::InterpreterDropQuery::executeToDatabaseImpl(DB::ASTDropQuery const&, std::shared_ptr&, std::vector, DB::UUIDTag>, std::allocator, DB::UUIDTag>>>&) @ 0x00000000149179be 6. /build/src/Interpreters/InterpreterDropQuery.cpp:363: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x0000000014913988 7. /build/src/Interpreters/InterpreterDropQuery.cpp:99: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000014913142 8. /build/src/Interpreters/InterpreterDropQuery.cpp:72: DB::InterpreterDropQuery::execute() @ 0x0000000014912b65 9. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88dc9 10. /build/src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x0000000014c8ca7b 11. /build/src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000001686da12 12. /build/src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x0000000016870807 13. /build/src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x0000000016907e99 14. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 15. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 16. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 17. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 18. ? @ 0x00007fbc6213eac3 19. ? @ 0x00007fbc621d0850 (version 25.3.6.10636.altinitytest (altinity build)) 2025.07.28 11:54:57.404105 [ 17287 ] {8ad1558d-fb98-48d7-badf-9e8673e45456} executeQuery: Code: 219. DB::Exception: New table appeared in database being dropped or detached. Try again. (DATABASE_NOT_EMPTY) (version 25.3.6.10636.altinitytest (altinity build)) (from [::1]:40316) (comment: 03267_materialized_view_keeps_security_context.sql) (in query: DROP DATABASE IF EXISTS test_auik66wh SYNC ), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000000a074fcb 4. /build/src/Interpreters/DatabaseCatalog.cpp:608: DB::DatabaseCatalog::detachDatabase(std::shared_ptr, String const&, bool, bool) @ 0x00000000144f41b9 5. /build/src/Interpreters/InterpreterDropQuery.cpp:482: DB::InterpreterDropQuery::executeToDatabaseImpl(DB::ASTDropQuery const&, std::shared_ptr&, std::vector, DB::UUIDTag>, std::allocator, DB::UUIDTag>>>&) @ 0x00000000149179be 6. /build/src/Interpreters/InterpreterDropQuery.cpp:363: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x0000000014913988 7. /build/src/Interpreters/InterpreterDropQuery.cpp:99: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000014913142 8. /build/src/Interpreters/InterpreterDropQuery.cpp:72: DB::InterpreterDropQuery::execute() @ 0x0000000014912b65 9. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88dc9 10. /build/src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x0000000014c8ca7b 11. /build/src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000001686da12 12. /build/src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x0000000016870807 13. /build/src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x0000000016907e99 14. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 15. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 16. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 17. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 18. ? @ 0x00007fbc6213eac3 19. ? @ 0x00007fbc621d0850 2025.07.28 11:54:57.405956 [ 17287 ] {8ad1558d-fb98-48d7-badf-9e8673e45456} 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. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000000a074fcb 4. /build/src/Interpreters/DatabaseCatalog.cpp:608: DB::DatabaseCatalog::detachDatabase(std::shared_ptr, String const&, bool, bool) @ 0x00000000144f41b9 5. /build/src/Interpreters/InterpreterDropQuery.cpp:482: DB::InterpreterDropQuery::executeToDatabaseImpl(DB::ASTDropQuery const&, std::shared_ptr&, std::vector, DB::UUIDTag>, std::allocator, DB::UUIDTag>>>&) @ 0x00000000149179be 6. /build/src/Interpreters/InterpreterDropQuery.cpp:363: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x0000000014913988 7. /build/src/Interpreters/InterpreterDropQuery.cpp:99: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000014913142 8. /build/src/Interpreters/InterpreterDropQuery.cpp:72: DB::InterpreterDropQuery::execute() @ 0x0000000014912b65 9. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88dc9 10. /build/src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x0000000014c8ca7b 11. /build/src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000001686da12 12. /build/src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x0000000016870807 13. /build/src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x0000000016907e99 14. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 15. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 16. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 17. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 18. ? @ 0x00007fbc6213eac3 19. ? @ 0x00007fbc621d0850 (version 25.3.6.10636.altinitytest (altinity build)) 2025.07.28 11:54:57.645784 [ 3960 ] {} test_13.rmt2 (7f9b740d-015c-470e-8cc6-8ba33be0dc63): auto DB::StorageReplicatedMergeTree::processQueueEntry(ReplicatedMergeTreeQueue::SelectedEntryPtr)::(anonymous class)::operator()(LogEntryPtr &) const: Code: 86. DB::HTTPException: Received error from remote server http://146b4357c08d:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Ftest%2F01165%2Ftest_13%2Frmt%2Freplicas%2F1&part=20250728_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.6.10636.altinitytest (altinity build)) '. (RECEIVED_ERROR_FROM_REMOTE_IO_SERVER), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.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 const&, int&&, String const&, unsigned long&&, String const&) @ 0x000000000feda8d9 4. /build/src/IO/HTTPCommon.cpp:104: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x000000000feda6e2 5. /build/src/IO/HTTPCommon.cpp:93: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x000000000feda537 6. /build/src/IO/ReadWriteBufferFromHTTP.cpp:277: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x000000001184a4c4 7. /build/src/IO/ReadWriteBufferFromHTTP.cpp:285: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x000000001184a615 8. /build/src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x000000001184ae59 9. /build/src/IO/ReadWriteBufferFromHTTP.cpp:472: void std::__function::__policy_invoker::__call_impl[abi:se190107]>(std::__function::__policy_storage const*) @ 0x000000001184cedd 10. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001184858b 11. /build/src/IO/ReadWriteBufferFromHTTP.cpp:465: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x000000001184bf0b 12. /build/src/IO/ReadBuffer.h:60: DB::ReadBuffer::next() @ 0x000000000a148c7b 13. /build/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) @ 0x0000000011849fb2 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]>&)>&, 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&) @ 0x0000000011841980 15. /build/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) @ 0x000000001621208e 16. /build/src/Storages/StorageReplicatedMergeTree.cpp:5228: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl[abi:se190107] const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000015f9a5fe 17. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000015ed8bfd 18. /build/src/Storages/StorageReplicatedMergeTree.cpp:2514: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x0000000015ec9aab 19. /build/src/Storages/StorageReplicatedMergeTree.cpp:2349: DB::StorageReplicatedMergeTree::executeLogEntry(DB::ReplicatedMergeTreeLogEntry&) @ 0x0000000015eba91b 20. /build/src/Storages/StorageReplicatedMergeTree.cpp:3876: bool std::__function::__policy_invoker&)>::__call_impl[abi:se190107])::$_1, bool (std::shared_ptr&)>>(std::__function::__policy_storage const*, std::shared_ptr&) @ 0x0000000015f9837e 21. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000165d6fc3 22. /build/src/Storages/StorageReplicatedMergeTree.cpp:3872: DB::StorageReplicatedMergeTree::processQueueEntry(std::shared_ptr) @ 0x0000000015efc18a 23. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001624c1b2 24. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000162f9c70 25. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x00000000162fa55a 26. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc6653 27. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000000fccc4c3 28. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc3d92 29. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fcca080 30. ? @ 0x00007fbc6213eac3 31. ? @ 0x00007fbc621d0850 (version 25.3.6.10636.altinitytest (altinity build)) 2025.07.28 11:54:58.495394 [ 3970 ] {} test_13.rmt2 (7f9b740d-015c-470e-8cc6-8ba33be0dc63): auto DB::StorageReplicatedMergeTree::processQueueEntry(ReplicatedMergeTreeQueue::SelectedEntryPtr)::(anonymous class)::operator()(LogEntryPtr &) const: Code: 86. DB::HTTPException: Received error from remote server http://146b4357c08d:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Ftest%2F01165%2Ftest_13%2Frmt%2Freplicas%2F1&part=20250728_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.6.10636.altinitytest (altinity build)) '. (RECEIVED_ERROR_FROM_REMOTE_IO_SERVER), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.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 const&, int&&, String const&, unsigned long&&, String const&) @ 0x000000000feda8d9 4. /build/src/IO/HTTPCommon.cpp:104: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x000000000feda6e2 5. /build/src/IO/HTTPCommon.cpp:93: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x000000000feda537 6. /build/src/IO/ReadWriteBufferFromHTTP.cpp:277: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x000000001184a4c4 7. /build/src/IO/ReadWriteBufferFromHTTP.cpp:285: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x000000001184a615 8. /build/src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x000000001184ae59 9. /build/src/IO/ReadWriteBufferFromHTTP.cpp:472: void std::__function::__policy_invoker::__call_impl[abi:se190107]>(std::__function::__policy_storage const*) @ 0x000000001184cedd 10. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001184858b 11. /build/src/IO/ReadWriteBufferFromHTTP.cpp:465: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x000000001184bf0b 12. /build/src/IO/ReadBuffer.h:60: DB::ReadBuffer::next() @ 0x000000000a148c7b 13. /build/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) @ 0x0000000011849fb2 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]>&)>&, 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&) @ 0x0000000011841980 15. /build/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) @ 0x000000001621208e 16. /build/src/Storages/StorageReplicatedMergeTree.cpp:5228: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl[abi:se190107] const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000015f9a5fe 17. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000015ed8bfd 18. /build/src/Storages/StorageReplicatedMergeTree.cpp:2514: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x0000000015ec9aab 19. /build/src/Storages/StorageReplicatedMergeTree.cpp:2349: DB::StorageReplicatedMergeTree::executeLogEntry(DB::ReplicatedMergeTreeLogEntry&) @ 0x0000000015eba91b 20. /build/src/Storages/StorageReplicatedMergeTree.cpp:3876: bool std::__function::__policy_invoker&)>::__call_impl[abi:se190107])::$_1, bool (std::shared_ptr&)>>(std::__function::__policy_storage const*, std::shared_ptr&) @ 0x0000000015f9837e 21. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000165d6fc3 22. /build/src/Storages/StorageReplicatedMergeTree.cpp:3872: DB::StorageReplicatedMergeTree::processQueueEntry(std::shared_ptr) @ 0x0000000015efc18a 23. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001624c1b2 24. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000162f9c70 25. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x00000000162fa55a 26. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc6653 27. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000000fccc4c3 28. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc3d92 29. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fcca080 30. ? @ 0x00007fbc6213eac3 31. ? @ 0x00007fbc621d0850 (version 25.3.6.10636.altinitytest (altinity build)) 2025.07.28 11:54:59.369834 [ 3972 ] {} test_13.rmt2 (7f9b740d-015c-470e-8cc6-8ba33be0dc63): auto DB::StorageReplicatedMergeTree::processQueueEntry(ReplicatedMergeTreeQueue::SelectedEntryPtr)::(anonymous class)::operator()(LogEntryPtr &) const: Code: 86. DB::HTTPException: Received error from remote server http://146b4357c08d:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Ftest%2F01165%2Ftest_13%2Frmt%2Freplicas%2F1&part=20250728_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.6.10636.altinitytest (altinity build)) '. (RECEIVED_ERROR_FROM_REMOTE_IO_SERVER), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.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 const&, int&&, String const&, unsigned long&&, String const&) @ 0x000000000feda8d9 4. /build/src/IO/HTTPCommon.cpp:104: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x000000000feda6e2 5. /build/src/IO/HTTPCommon.cpp:93: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x000000000feda537 6. /build/src/IO/ReadWriteBufferFromHTTP.cpp:277: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x000000001184a4c4 7. /build/src/IO/ReadWriteBufferFromHTTP.cpp:285: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x000000001184a615 8. /build/src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x000000001184ae59 9. /build/src/IO/ReadWriteBufferFromHTTP.cpp:472: void std::__function::__policy_invoker::__call_impl[abi:se190107]>(std::__function::__policy_storage const*) @ 0x000000001184cedd 10. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001184858b 11. /build/src/IO/ReadWriteBufferFromHTTP.cpp:465: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x000000001184bf0b 12. /build/src/IO/ReadBuffer.h:60: DB::ReadBuffer::next() @ 0x000000000a148c7b 13. /build/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) @ 0x0000000011849fb2 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]>&)>&, 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&) @ 0x0000000011841980 15. /build/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) @ 0x000000001621208e 16. /build/src/Storages/StorageReplicatedMergeTree.cpp:5228: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl[abi:se190107] const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000015f9a5fe 17. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000015ed8bfd 18. /build/src/Storages/StorageReplicatedMergeTree.cpp:2514: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x0000000015ec9aab 19. /build/src/Storages/StorageReplicatedMergeTree.cpp:2349: DB::StorageReplicatedMergeTree::executeLogEntry(DB::ReplicatedMergeTreeLogEntry&) @ 0x0000000015eba91b 20. /build/src/Storages/StorageReplicatedMergeTree.cpp:3876: bool std::__function::__policy_invoker&)>::__call_impl[abi:se190107])::$_1, bool (std::shared_ptr&)>>(std::__function::__policy_storage const*, std::shared_ptr&) @ 0x0000000015f9837e 21. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000165d6fc3 22. /build/src/Storages/StorageReplicatedMergeTree.cpp:3872: DB::StorageReplicatedMergeTree::processQueueEntry(std::shared_ptr) @ 0x0000000015efc18a 23. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001624c1b2 24. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000162f9c70 25. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x00000000162fa55a 26. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc6653 27. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000000fccc4c3 28. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc3d92 29. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fcca080 30. ? @ 0x00007fbc6213eac3 31. ? @ 0x00007fbc621d0850 (version 25.3.6.10636.altinitytest (altinity build)) 2025.07.28 11:54:59.993812 [ 3965 ] {} test_13.rmt2 (7f9b740d-015c-470e-8cc6-8ba33be0dc63): auto DB::StorageReplicatedMergeTree::processQueueEntry(ReplicatedMergeTreeQueue::SelectedEntryPtr)::(anonymous class)::operator()(LogEntryPtr &) const: Code: 86. DB::HTTPException: Received error from remote server http://146b4357c08d:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Ftest%2F01165%2Ftest_13%2Frmt%2Freplicas%2F1&part=20250728_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.6.10636.altinitytest (altinity build)) '. (RECEIVED_ERROR_FROM_REMOTE_IO_SERVER), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.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 const&, int&&, String const&, unsigned long&&, String const&) @ 0x000000000feda8d9 4. /build/src/IO/HTTPCommon.cpp:104: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x000000000feda6e2 5. /build/src/IO/HTTPCommon.cpp:93: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x000000000feda537 6. /build/src/IO/ReadWriteBufferFromHTTP.cpp:277: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x000000001184a4c4 7. /build/src/IO/ReadWriteBufferFromHTTP.cpp:285: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x000000001184a615 8. /build/src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x000000001184ae59 9. /build/src/IO/ReadWriteBufferFromHTTP.cpp:472: void std::__function::__policy_invoker::__call_impl[abi:se190107]>(std::__function::__policy_storage const*) @ 0x000000001184cedd 10. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001184858b 11. /build/src/IO/ReadWriteBufferFromHTTP.cpp:465: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x000000001184bf0b 12. /build/src/IO/ReadBuffer.h:60: DB::ReadBuffer::next() @ 0x000000000a148c7b 13. /build/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) @ 0x0000000011849fb2 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]>&)>&, 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&) @ 0x0000000011841980 15. /build/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) @ 0x000000001621208e 16. /build/src/Storages/StorageReplicatedMergeTree.cpp:5228: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl[abi:se190107] const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000015f9a5fe 17. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000015ed8bfd 18. /build/src/Storages/StorageReplicatedMergeTree.cpp:2514: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x0000000015ec9aab 19. /build/src/Storages/StorageReplicatedMergeTree.cpp:2349: DB::StorageReplicatedMergeTree::executeLogEntry(DB::ReplicatedMergeTreeLogEntry&) @ 0x0000000015eba91b 20. /build/src/Storages/StorageReplicatedMergeTree.cpp:3876: bool std::__function::__policy_invoker&)>::__call_impl[abi:se190107])::$_1, bool (std::shared_ptr&)>>(std::__function::__policy_storage const*, std::shared_ptr&) @ 0x0000000015f9837e 21. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000165d6fc3 22. /build/src/Storages/StorageReplicatedMergeTree.cpp:3872: DB::StorageReplicatedMergeTree::processQueueEntry(std::shared_ptr) @ 0x0000000015efc18a 23. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001624c1b2 24. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000162f9c70 25. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x00000000162fa55a 26. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc6653 27. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000000fccc4c3 28. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc3d92 29. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fcca080 30. ? @ 0x00007fbc6213eac3 31. ? @ 0x00007fbc621d0850 (version 25.3.6.10636.altinitytest (altinity build)) 2025.07.28 11:55:00.299005 [ 7630 ] {9096da3b-3adf-4ece-a478-ed6acbce6127} 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.6.10636.altinitytest (altinity build)) (from [::1]:52582) (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. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000000a074fcb 4. /build/src/Functions/GregorianDate.cpp:89: DB::(anonymous namespace)::readDigit(DB::ReadBuffer&) @ 0x000000000a9bcbf8 5. /build/src/Functions/GregorianDate.cpp:107: DB::GregorianDate::init(DB::ReadBuffer&) @ 0x000000000a9bc89a 6. /build/src/Functions/toModifiedJulianDay.cpp:89: DB::ExecutableFunctionToModifiedJulianDay, false>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000e85ed6b 7. /build/src/Functions/IFunction.h:57: DB::IExecutableFunction::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000a08134a 8. /build/src/Functions/IFunction.cpp:351: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d93b02 9. /build/src/Functions/IFunction.cpp:177: DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d93698 10. /build/src/Functions/IFunction.cpp:343: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d93aad 11. /build/src/Functions/IFunction.cpp:420: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d95059 12. /build/src/Functions/IFunction.cpp:498: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d95c72 13. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3567: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000014034494 14. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3838: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000014019a9e 15. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3980: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000014018e31 16. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:4304: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000014042fa7 17. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5605: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000014013749 18. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000140127f9 19. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000014011fce 20. /build/src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000001406ce8a 21. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000014973b42 22. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000001497268d 23. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000014974d24 24. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001492924b 25. /build/src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88641 26. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 27. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 28. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 29. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 30. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 31. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 2025.07.28 11:55:00.302989 [ 7630 ] {} 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. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000000a074fcb 4. /build/src/Functions/GregorianDate.cpp:89: DB::(anonymous namespace)::readDigit(DB::ReadBuffer&) @ 0x000000000a9bcbf8 5. /build/src/Functions/GregorianDate.cpp:107: DB::GregorianDate::init(DB::ReadBuffer&) @ 0x000000000a9bc89a 6. /build/src/Functions/toModifiedJulianDay.cpp:89: DB::ExecutableFunctionToModifiedJulianDay, false>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000e85ed6b 7. /build/src/Functions/IFunction.h:57: DB::IExecutableFunction::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000a08134a 8. /build/src/Functions/IFunction.cpp:351: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d93b02 9. /build/src/Functions/IFunction.cpp:177: DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d93698 10. /build/src/Functions/IFunction.cpp:343: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d93aad 11. /build/src/Functions/IFunction.cpp:420: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d95059 12. /build/src/Functions/IFunction.cpp:498: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d95c72 13. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3567: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000014034494 14. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3838: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000014019a9e 15. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3980: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000014018e31 16. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:4304: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000014042fa7 17. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5605: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000014013749 18. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000140127f9 19. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000014011fce 20. /build/src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000001406ce8a 21. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000014973b42 22. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000001497268d 23. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000014974d24 24. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001492924b 25. /build/src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88641 26. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 27. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 28. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 29. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 30. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 31. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 2025.07.28 11:55:00.368743 [ 7630 ] {44c50b5a-a9f5-4de0-952c-b1bd4045b5bf} 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.6.10636.altinitytest (altinity build)) (from [::1]:52582) (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. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, int&, unsigned char&, unsigned char&) @ 0x000000000a9be4ab 4. /build/src/Functions/GregorianDate.cpp:125: DB::GregorianDate::init(DB::ReadBuffer&) @ 0x000000000a9bcaa6 5. /build/src/Functions/toModifiedJulianDay.cpp:89: DB::ExecutableFunctionToModifiedJulianDay, false>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000e85ed6b 6. /build/src/Functions/IFunction.h:57: DB::IExecutableFunction::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000a08134a 7. /build/src/Functions/IFunction.cpp:351: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d93b02 8. /build/src/Functions/IFunction.cpp:177: DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d93698 9. /build/src/Functions/IFunction.cpp:343: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d93aad 10. /build/src/Functions/IFunction.cpp:420: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d95059 11. /build/src/Functions/IFunction.cpp:498: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d95c72 12. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3567: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000014034494 13. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3838: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000014019a9e 14. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3980: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000014018e31 15. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:4304: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000014042fa7 16. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5605: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000014013749 17. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000140127f9 18. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000014011fce 19. /build/src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000001406ce8a 20. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000014973b42 21. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000001497268d 22. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000014974d24 23. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001492924b 24. /build/src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88641 25. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 26. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 27. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 28. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 29. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 30. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 31. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 2025.07.28 11:55:00.379905 [ 7630 ] {} 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. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, int&, unsigned char&, unsigned char&) @ 0x000000000a9be4ab 4. /build/src/Functions/GregorianDate.cpp:125: DB::GregorianDate::init(DB::ReadBuffer&) @ 0x000000000a9bcaa6 5. /build/src/Functions/toModifiedJulianDay.cpp:89: DB::ExecutableFunctionToModifiedJulianDay, false>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000e85ed6b 6. /build/src/Functions/IFunction.h:57: DB::IExecutableFunction::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000a08134a 7. /build/src/Functions/IFunction.cpp:351: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d93b02 8. /build/src/Functions/IFunction.cpp:177: DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d93698 9. /build/src/Functions/IFunction.cpp:343: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d93aad 10. /build/src/Functions/IFunction.cpp:420: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d95059 11. /build/src/Functions/IFunction.cpp:498: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d95c72 12. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3567: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000014034494 13. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3838: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000014019a9e 14. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3980: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000014018e31 15. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:4304: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000014042fa7 16. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5605: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000014013749 17. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000140127f9 18. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000014011fce 19. /build/src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000001406ce8a 20. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000014973b42 21. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000001497268d 22. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000014974d24 23. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001492924b 24. /build/src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88641 25. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 26. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 27. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 28. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 29. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 30. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 31. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 2025.07.28 11:55:00.462250 [ 7630 ] {1fccdfd1-324f-4c81-a984-e1a15120a1b1} 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.6.10636.altinitytest (altinity build)) (from [::1]:52582) (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. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, int&, unsigned char&, unsigned char&) @ 0x000000000a9be4ab 4. /build/src/Functions/GregorianDate.cpp:125: DB::GregorianDate::init(DB::ReadBuffer&) @ 0x000000000a9bcaa6 5. /build/src/Functions/toModifiedJulianDay.cpp:89: DB::ExecutableFunctionToModifiedJulianDay, false>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000e85ed6b 6. /build/src/Functions/IFunction.h:57: DB::IExecutableFunction::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000a08134a 7. /build/src/Functions/IFunction.cpp:351: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d93b02 8. /build/src/Functions/IFunction.cpp:177: DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d93698 9. /build/src/Functions/IFunction.cpp:343: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d93aad 10. /build/src/Functions/IFunction.cpp:420: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d95059 11. /build/src/Functions/IFunction.cpp:498: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d95c72 12. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3567: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000014034494 13. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3838: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000014019a9e 14. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3980: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000014018e31 15. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:4304: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000014042fa7 16. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5605: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000014013749 17. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000140127f9 18. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000014011fce 19. /build/src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000001406ce8a 20. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000014973b42 21. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000001497268d 22. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000014974d24 23. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001492924b 24. /build/src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88641 25. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 26. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 27. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 28. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 29. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 30. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 31. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 2025.07.28 11:55:00.465022 [ 7630 ] {} 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. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, int&, unsigned char&, unsigned char&) @ 0x000000000a9be4ab 4. /build/src/Functions/GregorianDate.cpp:125: DB::GregorianDate::init(DB::ReadBuffer&) @ 0x000000000a9bcaa6 5. /build/src/Functions/toModifiedJulianDay.cpp:89: DB::ExecutableFunctionToModifiedJulianDay, false>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000e85ed6b 6. /build/src/Functions/IFunction.h:57: DB::IExecutableFunction::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000a08134a 7. /build/src/Functions/IFunction.cpp:351: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d93b02 8. /build/src/Functions/IFunction.cpp:177: DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d93698 9. /build/src/Functions/IFunction.cpp:343: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d93aad 10. /build/src/Functions/IFunction.cpp:420: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d95059 11. /build/src/Functions/IFunction.cpp:498: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d95c72 12. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3567: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000014034494 13. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3838: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000014019a9e 14. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3980: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000014018e31 15. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:4304: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000014042fa7 16. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5605: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000014013749 17. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000140127f9 18. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000014011fce 19. /build/src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000001406ce8a 20. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000014973b42 21. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000001497268d 22. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000014974d24 23. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001492924b 24. /build/src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88641 25. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 26. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 27. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 28. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 29. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 30. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 31. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 2025.07.28 11:55:00.858973 [ 3961 ] {} test_13.rmt2 (7f9b740d-015c-470e-8cc6-8ba33be0dc63): auto DB::StorageReplicatedMergeTree::processQueueEntry(ReplicatedMergeTreeQueue::SelectedEntryPtr)::(anonymous class)::operator()(LogEntryPtr &) const: Code: 86. DB::HTTPException: Received error from remote server http://146b4357c08d:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Ftest%2F01165%2Ftest_13%2Frmt%2Freplicas%2F1&part=20250728_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.6.10636.altinitytest (altinity build)) '. (RECEIVED_ERROR_FROM_REMOTE_IO_SERVER), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.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 const&, int&&, String const&, unsigned long&&, String const&) @ 0x000000000feda8d9 4. /build/src/IO/HTTPCommon.cpp:104: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x000000000feda6e2 5. /build/src/IO/HTTPCommon.cpp:93: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x000000000feda537 6. /build/src/IO/ReadWriteBufferFromHTTP.cpp:277: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x000000001184a4c4 7. /build/src/IO/ReadWriteBufferFromHTTP.cpp:285: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x000000001184a615 8. /build/src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x000000001184ae59 9. /build/src/IO/ReadWriteBufferFromHTTP.cpp:472: void std::__function::__policy_invoker::__call_impl[abi:se190107]>(std::__function::__policy_storage const*) @ 0x000000001184cedd 10. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001184858b 11. /build/src/IO/ReadWriteBufferFromHTTP.cpp:465: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x000000001184bf0b 12. /build/src/IO/ReadBuffer.h:60: DB::ReadBuffer::next() @ 0x000000000a148c7b 13. /build/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) @ 0x0000000011849fb2 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]>&)>&, 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&) @ 0x0000000011841980 15. /build/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) @ 0x000000001621208e 16. /build/src/Storages/StorageReplicatedMergeTree.cpp:5228: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl[abi:se190107] const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000015f9a5fe 17. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000015ed8bfd 18. /build/src/Storages/StorageReplicatedMergeTree.cpp:2514: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x0000000015ec9aab 19. /build/src/Storages/StorageReplicatedMergeTree.cpp:2349: DB::StorageReplicatedMergeTree::executeLogEntry(DB::ReplicatedMergeTreeLogEntry&) @ 0x0000000015eba91b 20. /build/src/Storages/StorageReplicatedMergeTree.cpp:3876: bool std::__function::__policy_invoker&)>::__call_impl[abi:se190107])::$_1, bool (std::shared_ptr&)>>(std::__function::__policy_storage const*, std::shared_ptr&) @ 0x0000000015f9837e 21. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000165d6fc3 22. /build/src/Storages/StorageReplicatedMergeTree.cpp:3872: DB::StorageReplicatedMergeTree::processQueueEntry(std::shared_ptr) @ 0x0000000015efc18a 23. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001624c1b2 24. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000162f9c70 25. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x00000000162fa55a 26. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc6653 27. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000000fccc4c3 28. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc3d92 29. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fcca080 30. ? @ 0x00007fbc6213eac3 31. ? @ 0x00007fbc621d0850 (version 25.3.6.10636.altinitytest (altinity build)) 2025.07.28 11:55:01.752777 [ 3967 ] {} test_13.rmt2 (7f9b740d-015c-470e-8cc6-8ba33be0dc63): auto DB::StorageReplicatedMergeTree::processQueueEntry(ReplicatedMergeTreeQueue::SelectedEntryPtr)::(anonymous class)::operator()(LogEntryPtr &) const: Code: 86. DB::HTTPException: Received error from remote server http://146b4357c08d:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Ftest%2F01165%2Ftest_13%2Frmt%2Freplicas%2F1&part=20250728_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.6.10636.altinitytest (altinity build)) '. (RECEIVED_ERROR_FROM_REMOTE_IO_SERVER), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.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 const&, int&&, String const&, unsigned long&&, String const&) @ 0x000000000feda8d9 4. /build/src/IO/HTTPCommon.cpp:104: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x000000000feda6e2 5. /build/src/IO/HTTPCommon.cpp:93: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x000000000feda537 6. /build/src/IO/ReadWriteBufferFromHTTP.cpp:277: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x000000001184a4c4 7. /build/src/IO/ReadWriteBufferFromHTTP.cpp:285: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x000000001184a615 8. /build/src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x000000001184ae59 9. /build/src/IO/ReadWriteBufferFromHTTP.cpp:472: void std::__function::__policy_invoker::__call_impl[abi:se190107]>(std::__function::__policy_storage const*) @ 0x000000001184cedd 10. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001184858b 11. /build/src/IO/ReadWriteBufferFromHTTP.cpp:465: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x000000001184bf0b 12. /build/src/IO/ReadBuffer.h:60: DB::ReadBuffer::next() @ 0x000000000a148c7b 13. /build/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) @ 0x0000000011849fb2 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]>&)>&, 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&) @ 0x0000000011841980 15. /build/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) @ 0x000000001621208e 16. /build/src/Storages/StorageReplicatedMergeTree.cpp:5228: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl[abi:se190107] const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000015f9a5fe 17. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000015ed8bfd 18. /build/src/Storages/StorageReplicatedMergeTree.cpp:2514: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x0000000015ec9aab 19. /build/src/Storages/StorageReplicatedMergeTree.cpp:2349: DB::StorageReplicatedMergeTree::executeLogEntry(DB::ReplicatedMergeTreeLogEntry&) @ 0x0000000015eba91b 20. /build/src/Storages/StorageReplicatedMergeTree.cpp:3876: bool std::__function::__policy_invoker&)>::__call_impl[abi:se190107])::$_1, bool (std::shared_ptr&)>>(std::__function::__policy_storage const*, std::shared_ptr&) @ 0x0000000015f9837e 21. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000165d6fc3 22. /build/src/Storages/StorageReplicatedMergeTree.cpp:3872: DB::StorageReplicatedMergeTree::processQueueEntry(std::shared_ptr) @ 0x0000000015efc18a 23. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001624c1b2 24. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000162f9c70 25. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x00000000162fa55a 26. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc6653 27. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000000fccc4c3 28. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc3d92 29. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fcca080 30. ? @ 0x00007fbc6213eac3 31. ? @ 0x00007fbc621d0850 (version 25.3.6.10636.altinitytest (altinity build)) 2025.07.28 11:55:01.949266 [ 17321 ] {3c69d8b1-48a6-4f88-8417-60f55e26f9c4} 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.6.10636.altinitytest (altinity build)) (from 0.0.0.0:0) (comment: 01416_clear_column_pk.sql) (in query: /* ddl_entry=query-0000000103 */ ALTER TABLE test_5.table_with_pk_clear (CLEAR COLUMN key1 IN PARTITION tuple())), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x000000000a06b56b 4. /build/src/Storages/MergeTree/MergeTreeData.cpp:3749: DB::MergeTreeData::checkAlterIsPossible(DB::AlterCommands const&, std::shared_ptr) const @ 0x00000000163381ae 5. /build/src/Interpreters/InterpreterAlterQuery.cpp:215: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x00000000148deab3 6. /build/src/Interpreters/InterpreterAlterQuery.cpp:77: DB::InterpreterAlterQuery::execute() @ 0x00000000148dcb0d 7. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88dc9 8. /build/src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x0000000014c8ca7b 9. /build/src/Interpreters/DDLWorker.cpp:510: DB::DDLWorker::tryExecuteQuery(DB::DDLTaskBase&, std::shared_ptr const&, bool) @ 0x00000000144dab9e 10. /build/src/Interpreters/DDLWorker.cpp:675: DB::DDLWorker::processTask(DB::DDLTaskBase&, std::shared_ptr const&, bool) @ 0x00000000144d8ffe 11. /build/src/Databases/DatabaseReplicatedWorker.cpp:372: DB::DatabaseReplicatedDDLWorker::tryEnqueueAndExecuteEntry(DB::DDLLogEntry&, std::shared_ptr, bool) @ 0x0000000013dc29ab 12. /build/src/Databases/DatabaseReplicated.cpp:1139: DB::DatabaseReplicated::tryEnqueueReplicatedDDL(std::shared_ptr const&, std::shared_ptr, DB::QueryFlags) @ 0x0000000013d9f73c 13. /build/src/Interpreters/InterpreterAlterQuery.cpp:130: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x00000000148dd805 14. /build/src/Interpreters/InterpreterAlterQuery.cpp:77: DB::InterpreterAlterQuery::execute() @ 0x00000000148dcb0d 15. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88dc9 16. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 17. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 18. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 19. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 20. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 21. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 22. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 23. ? @ 0x00007fbc6213eac3 24. ? @ 0x00007fbc621d0850 2025.07.28 11:55:01.989387 [ 17321 ] {3c69d8b1-48a6-4f88-8417-60f55e26f9c4} 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.6.10636.altinitytest (altinity build)) (from [::1]:38560) (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. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x000000000a06b56b 4. /build/src/Storages/MergeTree/MergeTreeData.cpp:3749: DB::MergeTreeData::checkAlterIsPossible(DB::AlterCommands const&, std::shared_ptr) const @ 0x00000000163381ae 5. /build/src/Interpreters/InterpreterAlterQuery.cpp:215: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x00000000148deab3 6. /build/src/Interpreters/InterpreterAlterQuery.cpp:77: DB::InterpreterAlterQuery::execute() @ 0x00000000148dcb0d 7. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88dc9 8. /build/src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x0000000014c8ca7b 9. /build/src/Interpreters/DDLWorker.cpp:510: DB::DDLWorker::tryExecuteQuery(DB::DDLTaskBase&, std::shared_ptr const&, bool) @ 0x00000000144dab9e 10. /build/src/Interpreters/DDLWorker.cpp:675: DB::DDLWorker::processTask(DB::DDLTaskBase&, std::shared_ptr const&, bool) @ 0x00000000144d8ffe 11. /build/src/Databases/DatabaseReplicatedWorker.cpp:372: DB::DatabaseReplicatedDDLWorker::tryEnqueueAndExecuteEntry(DB::DDLLogEntry&, std::shared_ptr, bool) @ 0x0000000013dc29ab 12. /build/src/Databases/DatabaseReplicated.cpp:1139: DB::DatabaseReplicated::tryEnqueueReplicatedDDL(std::shared_ptr const&, std::shared_ptr, DB::QueryFlags) @ 0x0000000013d9f73c 13. /build/src/Interpreters/InterpreterAlterQuery.cpp:130: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x00000000148dd805 14. /build/src/Interpreters/InterpreterAlterQuery.cpp:77: DB::InterpreterAlterQuery::execute() @ 0x00000000148dcb0d 15. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88dc9 16. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 17. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 18. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 19. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 20. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 21. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 22. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 23. ? @ 0x00007fbc6213eac3 24. ? @ 0x00007fbc621d0850 2025.07.28 11:55:01.992918 [ 17321 ] {} 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. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x000000000a06b56b 4. /build/src/Storages/MergeTree/MergeTreeData.cpp:3749: DB::MergeTreeData::checkAlterIsPossible(DB::AlterCommands const&, std::shared_ptr) const @ 0x00000000163381ae 5. /build/src/Interpreters/InterpreterAlterQuery.cpp:215: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x00000000148deab3 6. /build/src/Interpreters/InterpreterAlterQuery.cpp:77: DB::InterpreterAlterQuery::execute() @ 0x00000000148dcb0d 7. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88dc9 8. /build/src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x0000000014c8ca7b 9. /build/src/Interpreters/DDLWorker.cpp:510: DB::DDLWorker::tryExecuteQuery(DB::DDLTaskBase&, std::shared_ptr const&, bool) @ 0x00000000144dab9e 10. /build/src/Interpreters/DDLWorker.cpp:675: DB::DDLWorker::processTask(DB::DDLTaskBase&, std::shared_ptr const&, bool) @ 0x00000000144d8ffe 11. /build/src/Databases/DatabaseReplicatedWorker.cpp:372: DB::DatabaseReplicatedDDLWorker::tryEnqueueAndExecuteEntry(DB::DDLLogEntry&, std::shared_ptr, bool) @ 0x0000000013dc29ab 12. /build/src/Databases/DatabaseReplicated.cpp:1139: DB::DatabaseReplicated::tryEnqueueReplicatedDDL(std::shared_ptr const&, std::shared_ptr, DB::QueryFlags) @ 0x0000000013d9f73c 13. /build/src/Interpreters/InterpreterAlterQuery.cpp:130: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x00000000148dd805 14. /build/src/Interpreters/InterpreterAlterQuery.cpp:77: DB::InterpreterAlterQuery::execute() @ 0x00000000148dcb0d 15. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88dc9 16. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 17. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 18. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 19. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 20. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 21. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 22. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 23. ? @ 0x00007fbc6213eac3 24. ? @ 0x00007fbc621d0850 2025.07.28 11:55:02.201177 [ 17321 ] {b02f7d8e-9d52-4fff-992d-439de5c192c8} 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.6.10636.altinitytest (altinity build)) (from 0.0.0.0:0) (comment: 01416_clear_column_pk.sql) (in query: /* ddl_entry=query-0000000104 */ ALTER TABLE test_5.table_with_pk_clear (CLEAR COLUMN key2 IN PARTITION tuple())), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x000000000a06b56b 4. /build/src/Storages/MergeTree/MergeTreeData.cpp:3749: DB::MergeTreeData::checkAlterIsPossible(DB::AlterCommands const&, std::shared_ptr) const @ 0x00000000163381ae 5. /build/src/Interpreters/InterpreterAlterQuery.cpp:215: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x00000000148deab3 6. /build/src/Interpreters/InterpreterAlterQuery.cpp:77: DB::InterpreterAlterQuery::execute() @ 0x00000000148dcb0d 7. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88dc9 8. /build/src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x0000000014c8ca7b 9. /build/src/Interpreters/DDLWorker.cpp:510: DB::DDLWorker::tryExecuteQuery(DB::DDLTaskBase&, std::shared_ptr const&, bool) @ 0x00000000144dab9e 10. /build/src/Interpreters/DDLWorker.cpp:675: DB::DDLWorker::processTask(DB::DDLTaskBase&, std::shared_ptr const&, bool) @ 0x00000000144d8ffe 11. /build/src/Databases/DatabaseReplicatedWorker.cpp:372: DB::DatabaseReplicatedDDLWorker::tryEnqueueAndExecuteEntry(DB::DDLLogEntry&, std::shared_ptr, bool) @ 0x0000000013dc29ab 12. /build/src/Databases/DatabaseReplicated.cpp:1139: DB::DatabaseReplicated::tryEnqueueReplicatedDDL(std::shared_ptr const&, std::shared_ptr, DB::QueryFlags) @ 0x0000000013d9f73c 13. /build/src/Interpreters/InterpreterAlterQuery.cpp:130: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x00000000148dd805 14. /build/src/Interpreters/InterpreterAlterQuery.cpp:77: DB::InterpreterAlterQuery::execute() @ 0x00000000148dcb0d 15. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88dc9 16. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 17. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 18. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 19. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 20. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 21. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 22. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 23. ? @ 0x00007fbc6213eac3 24. ? @ 0x00007fbc621d0850 2025.07.28 11:55:02.213392 [ 3963 ] {} test_13.rmt2 (7f9b740d-015c-470e-8cc6-8ba33be0dc63): auto DB::StorageReplicatedMergeTree::processQueueEntry(ReplicatedMergeTreeQueue::SelectedEntryPtr)::(anonymous class)::operator()(LogEntryPtr &) const: Code: 86. DB::HTTPException: Received error from remote server http://146b4357c08d:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Ftest%2F01165%2Ftest_13%2Frmt%2Freplicas%2F1&part=20250728_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.6.10636.altinitytest (altinity build)) '. (RECEIVED_ERROR_FROM_REMOTE_IO_SERVER), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.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 const&, int&&, String const&, unsigned long&&, String const&) @ 0x000000000feda8d9 4. /build/src/IO/HTTPCommon.cpp:104: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x000000000feda6e2 5. /build/src/IO/HTTPCommon.cpp:93: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x000000000feda537 6. /build/src/IO/ReadWriteBufferFromHTTP.cpp:277: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x000000001184a4c4 7. /build/src/IO/ReadWriteBufferFromHTTP.cpp:285: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x000000001184a615 8. /build/src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x000000001184ae59 9. /build/src/IO/ReadWriteBufferFromHTTP.cpp:472: void std::__function::__policy_invoker::__call_impl[abi:se190107]>(std::__function::__policy_storage const*) @ 0x000000001184cedd 10. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001184858b 11. /build/src/IO/ReadWriteBufferFromHTTP.cpp:465: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x000000001184bf0b 12. /build/src/IO/ReadBuffer.h:60: DB::ReadBuffer::next() @ 0x000000000a148c7b 13. /build/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) @ 0x0000000011849fb2 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]>&)>&, 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&) @ 0x0000000011841980 15. /build/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) @ 0x000000001621208e 16. /build/src/Storages/StorageReplicatedMergeTree.cpp:5228: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl[abi:se190107] const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000015f9a5fe 17. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000015ed8bfd 18. /build/src/Storages/StorageReplicatedMergeTree.cpp:2514: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x0000000015ec9aab 19. /build/src/Storages/StorageReplicatedMergeTree.cpp:2349: DB::StorageReplicatedMergeTree::executeLogEntry(DB::ReplicatedMergeTreeLogEntry&) @ 0x0000000015eba91b 20. /build/src/Storages/StorageReplicatedMergeTree.cpp:3876: bool std::__function::__policy_invoker&)>::__call_impl[abi:se190107])::$_1, bool (std::shared_ptr&)>>(std::__function::__policy_storage const*, std::shared_ptr&) @ 0x0000000015f9837e 21. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000165d6fc3 22. /build/src/Storages/StorageReplicatedMergeTree.cpp:3872: DB::StorageReplicatedMergeTree::processQueueEntry(std::shared_ptr) @ 0x0000000015efc18a 23. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001624c1b2 24. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000162f9c70 25. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x00000000162fa55a 26. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc6653 27. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000000fccc4c3 28. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc3d92 29. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fcca080 30. ? @ 0x00007fbc6213eac3 31. ? @ 0x00007fbc621d0850 (version 25.3.6.10636.altinitytest (altinity build)) 2025.07.28 11:55:02.230348 [ 17321 ] {b02f7d8e-9d52-4fff-992d-439de5c192c8} 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.6.10636.altinitytest (altinity build)) (from [::1]:38560) (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. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x000000000a06b56b 4. /build/src/Storages/MergeTree/MergeTreeData.cpp:3749: DB::MergeTreeData::checkAlterIsPossible(DB::AlterCommands const&, std::shared_ptr) const @ 0x00000000163381ae 5. /build/src/Interpreters/InterpreterAlterQuery.cpp:215: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x00000000148deab3 6. /build/src/Interpreters/InterpreterAlterQuery.cpp:77: DB::InterpreterAlterQuery::execute() @ 0x00000000148dcb0d 7. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88dc9 8. /build/src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x0000000014c8ca7b 9. /build/src/Interpreters/DDLWorker.cpp:510: DB::DDLWorker::tryExecuteQuery(DB::DDLTaskBase&, std::shared_ptr const&, bool) @ 0x00000000144dab9e 10. /build/src/Interpreters/DDLWorker.cpp:675: DB::DDLWorker::processTask(DB::DDLTaskBase&, std::shared_ptr const&, bool) @ 0x00000000144d8ffe 11. /build/src/Databases/DatabaseReplicatedWorker.cpp:372: DB::DatabaseReplicatedDDLWorker::tryEnqueueAndExecuteEntry(DB::DDLLogEntry&, std::shared_ptr, bool) @ 0x0000000013dc29ab 12. /build/src/Databases/DatabaseReplicated.cpp:1139: DB::DatabaseReplicated::tryEnqueueReplicatedDDL(std::shared_ptr const&, std::shared_ptr, DB::QueryFlags) @ 0x0000000013d9f73c 13. /build/src/Interpreters/InterpreterAlterQuery.cpp:130: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x00000000148dd805 14. /build/src/Interpreters/InterpreterAlterQuery.cpp:77: DB::InterpreterAlterQuery::execute() @ 0x00000000148dcb0d 15. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88dc9 16. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 17. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 18. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 19. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 20. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 21. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 22. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 23. ? @ 0x00007fbc6213eac3 24. ? @ 0x00007fbc621d0850 2025.07.28 11:55:02.233498 [ 17321 ] {} 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. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x000000000a06b56b 4. /build/src/Storages/MergeTree/MergeTreeData.cpp:3749: DB::MergeTreeData::checkAlterIsPossible(DB::AlterCommands const&, std::shared_ptr) const @ 0x00000000163381ae 5. /build/src/Interpreters/InterpreterAlterQuery.cpp:215: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x00000000148deab3 6. /build/src/Interpreters/InterpreterAlterQuery.cpp:77: DB::InterpreterAlterQuery::execute() @ 0x00000000148dcb0d 7. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88dc9 8. /build/src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x0000000014c8ca7b 9. /build/src/Interpreters/DDLWorker.cpp:510: DB::DDLWorker::tryExecuteQuery(DB::DDLTaskBase&, std::shared_ptr const&, bool) @ 0x00000000144dab9e 10. /build/src/Interpreters/DDLWorker.cpp:675: DB::DDLWorker::processTask(DB::DDLTaskBase&, std::shared_ptr const&, bool) @ 0x00000000144d8ffe 11. /build/src/Databases/DatabaseReplicatedWorker.cpp:372: DB::DatabaseReplicatedDDLWorker::tryEnqueueAndExecuteEntry(DB::DDLLogEntry&, std::shared_ptr, bool) @ 0x0000000013dc29ab 12. /build/src/Databases/DatabaseReplicated.cpp:1139: DB::DatabaseReplicated::tryEnqueueReplicatedDDL(std::shared_ptr const&, std::shared_ptr, DB::QueryFlags) @ 0x0000000013d9f73c 13. /build/src/Interpreters/InterpreterAlterQuery.cpp:130: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x00000000148dd805 14. /build/src/Interpreters/InterpreterAlterQuery.cpp:77: DB::InterpreterAlterQuery::execute() @ 0x00000000148dcb0d 15. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88dc9 16. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 17. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 18. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 19. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 20. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 21. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 22. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 23. ? @ 0x00007fbc6213eac3 24. ? @ 0x00007fbc621d0850 2025.07.28 11:55:03.329280 [ 3971 ] {} test_13.rmt2 (7f9b740d-015c-470e-8cc6-8ba33be0dc63): auto DB::StorageReplicatedMergeTree::processQueueEntry(ReplicatedMergeTreeQueue::SelectedEntryPtr)::(anonymous class)::operator()(LogEntryPtr &) const: Code: 86. DB::HTTPException: Received error from remote server http://146b4357c08d:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Ftest%2F01165%2Ftest_13%2Frmt%2Freplicas%2F1&part=20250728_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.6.10636.altinitytest (altinity build)) '. (RECEIVED_ERROR_FROM_REMOTE_IO_SERVER), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.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 const&, int&&, String const&, unsigned long&&, String const&) @ 0x000000000feda8d9 4. /build/src/IO/HTTPCommon.cpp:104: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x000000000feda6e2 5. /build/src/IO/HTTPCommon.cpp:93: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x000000000feda537 6. /build/src/IO/ReadWriteBufferFromHTTP.cpp:277: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x000000001184a4c4 7. /build/src/IO/ReadWriteBufferFromHTTP.cpp:285: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x000000001184a615 8. /build/src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x000000001184ae59 9. /build/src/IO/ReadWriteBufferFromHTTP.cpp:472: void std::__function::__policy_invoker::__call_impl[abi:se190107]>(std::__function::__policy_storage const*) @ 0x000000001184cedd 10. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001184858b 11. /build/src/IO/ReadWriteBufferFromHTTP.cpp:465: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x000000001184bf0b 12. /build/src/IO/ReadBuffer.h:60: DB::ReadBuffer::next() @ 0x000000000a148c7b 13. /build/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) @ 0x0000000011849fb2 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]>&)>&, 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&) @ 0x0000000011841980 15. /build/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) @ 0x000000001621208e 16. /build/src/Storages/StorageReplicatedMergeTree.cpp:5228: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl[abi:se190107] const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000015f9a5fe 17. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000015ed8bfd 18. /build/src/Storages/StorageReplicatedMergeTree.cpp:2514: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x0000000015ec9aab 19. /build/src/Storages/StorageReplicatedMergeTree.cpp:2349: DB::StorageReplicatedMergeTree::executeLogEntry(DB::ReplicatedMergeTreeLogEntry&) @ 0x0000000015eba91b 20. /build/src/Storages/StorageReplicatedMergeTree.cpp:3876: bool std::__function::__policy_invoker&)>::__call_impl[abi:se190107])::$_1, bool (std::shared_ptr&)>>(std::__function::__policy_storage const*, std::shared_ptr&) @ 0x0000000015f9837e 21. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000165d6fc3 22. /build/src/Storages/StorageReplicatedMergeTree.cpp:3872: DB::StorageReplicatedMergeTree::processQueueEntry(std::shared_ptr) @ 0x0000000015efc18a 23. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001624c1b2 24. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000162f9c70 25. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x00000000162fa55a 26. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc6653 27. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000000fccc4c3 28. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc3d92 29. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fcca080 30. ? @ 0x00007fbc6213eac3 31. ? @ 0x00007fbc621d0850 (version 25.3.6.10636.altinitytest (altinity build)) 2025.07.28 11:55:03.410706 [ 3972 ] {} test_13.rmt2 (7f9b740d-015c-470e-8cc6-8ba33be0dc63): auto DB::StorageReplicatedMergeTree::processQueueEntry(ReplicatedMergeTreeQueue::SelectedEntryPtr)::(anonymous class)::operator()(LogEntryPtr &) const: Code: 86. DB::HTTPException: Received error from remote server http://146b4357c08d:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Ftest%2F01165%2Ftest_13%2Frmt%2Freplicas%2F1&part=20250728_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.6.10636.altinitytest (altinity build)) '. (RECEIVED_ERROR_FROM_REMOTE_IO_SERVER), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.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 const&, int&&, String const&, unsigned long&&, String const&) @ 0x000000000feda8d9 4. /build/src/IO/HTTPCommon.cpp:104: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x000000000feda6e2 5. /build/src/IO/HTTPCommon.cpp:93: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x000000000feda537 6. /build/src/IO/ReadWriteBufferFromHTTP.cpp:277: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x000000001184a4c4 7. /build/src/IO/ReadWriteBufferFromHTTP.cpp:285: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x000000001184a615 8. /build/src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x000000001184ae59 9. /build/src/IO/ReadWriteBufferFromHTTP.cpp:472: void std::__function::__policy_invoker::__call_impl[abi:se190107]>(std::__function::__policy_storage const*) @ 0x000000001184cedd 10. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001184858b 11. /build/src/IO/ReadWriteBufferFromHTTP.cpp:465: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x000000001184bf0b 12. /build/src/IO/ReadBuffer.h:60: DB::ReadBuffer::next() @ 0x000000000a148c7b 13. /build/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) @ 0x0000000011849fb2 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]>&)>&, 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&) @ 0x0000000011841980 15. /build/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) @ 0x000000001621208e 16. /build/src/Storages/StorageReplicatedMergeTree.cpp:5228: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl[abi:se190107] const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000015f9a5fe 17. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000015ed8bfd 18. /build/src/Storages/StorageReplicatedMergeTree.cpp:2514: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x0000000015ec9aab 19. /build/src/Storages/StorageReplicatedMergeTree.cpp:2349: DB::StorageReplicatedMergeTree::executeLogEntry(DB::ReplicatedMergeTreeLogEntry&) @ 0x0000000015eba91b 20. /build/src/Storages/StorageReplicatedMergeTree.cpp:3876: bool std::__function::__policy_invoker&)>::__call_impl[abi:se190107])::$_1, bool (std::shared_ptr&)>>(std::__function::__policy_storage const*, std::shared_ptr&) @ 0x0000000015f9837e 21. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000165d6fc3 22. /build/src/Storages/StorageReplicatedMergeTree.cpp:3872: DB::StorageReplicatedMergeTree::processQueueEntry(std::shared_ptr) @ 0x0000000015efc18a 23. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001624c1b2 24. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000162f9c70 25. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x00000000162fa55a 26. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc6653 27. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000000fccc4c3 28. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc3d92 29. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fcca080 30. ? @ 0x00007fbc6213eac3 31. ? @ 0x00007fbc621d0850 (version 25.3.6.10636.altinitytest (altinity build)) 2025.07.28 11:55:03.625502 [ 3960 ] {} test_13.rmt2 (7f9b740d-015c-470e-8cc6-8ba33be0dc63): auto DB::StorageReplicatedMergeTree::processQueueEntry(ReplicatedMergeTreeQueue::SelectedEntryPtr)::(anonymous class)::operator()(LogEntryPtr &) const: Code: 86. DB::HTTPException: Received error from remote server http://146b4357c08d:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Ftest%2F01165%2Ftest_13%2Frmt%2Freplicas%2F1&part=20250728_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.6.10636.altinitytest (altinity build)) '. (RECEIVED_ERROR_FROM_REMOTE_IO_SERVER), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.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 const&, int&&, String const&, unsigned long&&, String const&) @ 0x000000000feda8d9 4. /build/src/IO/HTTPCommon.cpp:104: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x000000000feda6e2 5. /build/src/IO/HTTPCommon.cpp:93: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x000000000feda537 6. /build/src/IO/ReadWriteBufferFromHTTP.cpp:277: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x000000001184a4c4 7. /build/src/IO/ReadWriteBufferFromHTTP.cpp:285: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x000000001184a615 8. /build/src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x000000001184ae59 9. /build/src/IO/ReadWriteBufferFromHTTP.cpp:472: void std::__function::__policy_invoker::__call_impl[abi:se190107]>(std::__function::__policy_storage const*) @ 0x000000001184cedd 10. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001184858b 11. /build/src/IO/ReadWriteBufferFromHTTP.cpp:465: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x000000001184bf0b 12. /build/src/IO/ReadBuffer.h:60: DB::ReadBuffer::next() @ 0x000000000a148c7b 13. /build/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) @ 0x0000000011849fb2 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]>&)>&, 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&) @ 0x0000000011841980 15. /build/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) @ 0x000000001621208e 16. /build/src/Storages/StorageReplicatedMergeTree.cpp:5228: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl[abi:se190107] const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000015f9a5fe 17. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000015ed8bfd 18. /build/src/Storages/StorageReplicatedMergeTree.cpp:2514: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x0000000015ec9aab 19. /build/src/Storages/StorageReplicatedMergeTree.cpp:2349: DB::StorageReplicatedMergeTree::executeLogEntry(DB::ReplicatedMergeTreeLogEntry&) @ 0x0000000015eba91b 20. /build/src/Storages/StorageReplicatedMergeTree.cpp:3876: bool std::__function::__policy_invoker&)>::__call_impl[abi:se190107])::$_1, bool (std::shared_ptr&)>>(std::__function::__policy_storage const*, std::shared_ptr&) @ 0x0000000015f9837e 21. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000165d6fc3 22. /build/src/Storages/StorageReplicatedMergeTree.cpp:3872: DB::StorageReplicatedMergeTree::processQueueEntry(std::shared_ptr) @ 0x0000000015efc18a 23. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001624c1b2 24. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000162f9c70 25. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x00000000162fa55a 26. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc6653 27. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000000fccc4c3 28. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc3d92 29. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fcca080 30. ? @ 0x00007fbc6213eac3 31. ? @ 0x00007fbc621d0850 (version 25.3.6.10636.altinitytest (altinity build)) 2025.07.28 11:55:04.128304 [ 3968 ] {} test_13.rmt2 (7f9b740d-015c-470e-8cc6-8ba33be0dc63): auto DB::StorageReplicatedMergeTree::processQueueEntry(ReplicatedMergeTreeQueue::SelectedEntryPtr)::(anonymous class)::operator()(LogEntryPtr &) const: Code: 86. DB::HTTPException: Received error from remote server http://146b4357c08d:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Ftest%2F01165%2Ftest_13%2Frmt%2Freplicas%2F1&part=20250728_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.6.10636.altinitytest (altinity build)) '. (RECEIVED_ERROR_FROM_REMOTE_IO_SERVER), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.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 const&, int&&, String const&, unsigned long&&, String const&) @ 0x000000000feda8d9 4. /build/src/IO/HTTPCommon.cpp:104: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x000000000feda6e2 5. /build/src/IO/HTTPCommon.cpp:93: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x000000000feda537 6. /build/src/IO/ReadWriteBufferFromHTTP.cpp:277: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x000000001184a4c4 7. /build/src/IO/ReadWriteBufferFromHTTP.cpp:285: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x000000001184a615 8. /build/src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x000000001184ae59 9. /build/src/IO/ReadWriteBufferFromHTTP.cpp:472: void std::__function::__policy_invoker::__call_impl[abi:se190107]>(std::__function::__policy_storage const*) @ 0x000000001184cedd 10. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001184858b 11. /build/src/IO/ReadWriteBufferFromHTTP.cpp:465: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x000000001184bf0b 12. /build/src/IO/ReadBuffer.h:60: DB::ReadBuffer::next() @ 0x000000000a148c7b 13. /build/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) @ 0x0000000011849fb2 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]>&)>&, 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&) @ 0x0000000011841980 15. /build/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) @ 0x000000001621208e 16. /build/src/Storages/StorageReplicatedMergeTree.cpp:5228: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl[abi:se190107] const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000015f9a5fe 17. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000015ed8bfd 18. /build/src/Storages/StorageReplicatedMergeTree.cpp:2514: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x0000000015ec9aab 19. /build/src/Storages/StorageReplicatedMergeTree.cpp:2349: DB::StorageReplicatedMergeTree::executeLogEntry(DB::ReplicatedMergeTreeLogEntry&) @ 0x0000000015eba91b 20. /build/src/Storages/StorageReplicatedMergeTree.cpp:3876: bool std::__function::__policy_invoker&)>::__call_impl[abi:se190107])::$_1, bool (std::shared_ptr&)>>(std::__function::__policy_storage const*, std::shared_ptr&) @ 0x0000000015f9837e 21. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000165d6fc3 22. /build/src/Storages/StorageReplicatedMergeTree.cpp:3872: DB::StorageReplicatedMergeTree::processQueueEntry(std::shared_ptr) @ 0x0000000015efc18a 23. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001624c1b2 24. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000162f9c70 25. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x00000000162fa55a 26. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc6653 27. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000000fccc4c3 28. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc3d92 29. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fcca080 30. ? @ 0x00007fbc6213eac3 31. ? @ 0x00007fbc621d0850 (version 25.3.6.10636.altinitytest (altinity build)) 2025.07.28 11:55:04.560300 [ 3976 ] {} test_13.rmt2 (7f9b740d-015c-470e-8cc6-8ba33be0dc63): auto DB::StorageReplicatedMergeTree::processQueueEntry(ReplicatedMergeTreeQueue::SelectedEntryPtr)::(anonymous class)::operator()(LogEntryPtr &) const: Code: 86. DB::HTTPException: Received error from remote server http://146b4357c08d:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Ftest%2F01165%2Ftest_13%2Frmt%2Freplicas%2F1&part=20250728_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.6.10636.altinitytest (altinity build)) '. (RECEIVED_ERROR_FROM_REMOTE_IO_SERVER), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.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 const&, int&&, String const&, unsigned long&&, String const&) @ 0x000000000feda8d9 4. /build/src/IO/HTTPCommon.cpp:104: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x000000000feda6e2 5. /build/src/IO/HTTPCommon.cpp:93: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x000000000feda537 6. /build/src/IO/ReadWriteBufferFromHTTP.cpp:277: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x000000001184a4c4 7. /build/src/IO/ReadWriteBufferFromHTTP.cpp:285: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x000000001184a615 8. /build/src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x000000001184ae59 9. /build/src/IO/ReadWriteBufferFromHTTP.cpp:472: void std::__function::__policy_invoker::__call_impl[abi:se190107]>(std::__function::__policy_storage const*) @ 0x000000001184cedd 10. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001184858b 11. /build/src/IO/ReadWriteBufferFromHTTP.cpp:465: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x000000001184bf0b 12. /build/src/IO/ReadBuffer.h:60: DB::ReadBuffer::next() @ 0x000000000a148c7b 13. /build/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) @ 0x0000000011849fb2 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]>&)>&, 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&) @ 0x0000000011841980 15. /build/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) @ 0x000000001621208e 16. /build/src/Storages/StorageReplicatedMergeTree.cpp:5228: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl[abi:se190107] const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000015f9a5fe 17. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000015ed8bfd 18. /build/src/Storages/StorageReplicatedMergeTree.cpp:2514: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x0000000015ec9aab 19. /build/src/Storages/StorageReplicatedMergeTree.cpp:2349: DB::StorageReplicatedMergeTree::executeLogEntry(DB::ReplicatedMergeTreeLogEntry&) @ 0x0000000015eba91b 20. /build/src/Storages/StorageReplicatedMergeTree.cpp:3876: bool std::__function::__policy_invoker&)>::__call_impl[abi:se190107])::$_1, bool (std::shared_ptr&)>>(std::__function::__policy_storage const*, std::shared_ptr&) @ 0x0000000015f9837e 21. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000165d6fc3 22. /build/src/Storages/StorageReplicatedMergeTree.cpp:3872: DB::StorageReplicatedMergeTree::processQueueEntry(std::shared_ptr) @ 0x0000000015efc18a 23. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001624c1b2 24. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000162f9c70 25. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x00000000162fa55a 26. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc6653 27. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000000fccc4c3 28. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc3d92 29. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fcca080 30. ? @ 0x00007fbc6213eac3 31. ? @ 0x00007fbc621d0850 (version 25.3.6.10636.altinitytest (altinity build)) 2025.07.28 11:55:05.134941 [ 3965 ] {} test_13.rmt2 (7f9b740d-015c-470e-8cc6-8ba33be0dc63): auto DB::StorageReplicatedMergeTree::processQueueEntry(ReplicatedMergeTreeQueue::SelectedEntryPtr)::(anonymous class)::operator()(LogEntryPtr &) const: Code: 86. DB::HTTPException: Received error from remote server http://146b4357c08d:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Ftest%2F01165%2Ftest_13%2Frmt%2Freplicas%2F1&part=20250728_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.6.10636.altinitytest (altinity build)) '. (RECEIVED_ERROR_FROM_REMOTE_IO_SERVER), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.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 const&, int&&, String const&, unsigned long&&, String const&) @ 0x000000000feda8d9 4. /build/src/IO/HTTPCommon.cpp:104: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x000000000feda6e2 5. /build/src/IO/HTTPCommon.cpp:93: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x000000000feda537 6. /build/src/IO/ReadWriteBufferFromHTTP.cpp:277: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x000000001184a4c4 7. /build/src/IO/ReadWriteBufferFromHTTP.cpp:285: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x000000001184a615 8. /build/src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x000000001184ae59 9. /build/src/IO/ReadWriteBufferFromHTTP.cpp:472: void std::__function::__policy_invoker::__call_impl[abi:se190107]>(std::__function::__policy_storage const*) @ 0x000000001184cedd 10. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001184858b 11. /build/src/IO/ReadWriteBufferFromHTTP.cpp:465: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x000000001184bf0b 12. /build/src/IO/ReadBuffer.h:60: DB::ReadBuffer::next() @ 0x000000000a148c7b 13. /build/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) @ 0x0000000011849fb2 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]>&)>&, 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&) @ 0x0000000011841980 15. /build/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) @ 0x000000001621208e 16. /build/src/Storages/StorageReplicatedMergeTree.cpp:5228: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl[abi:se190107] const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000015f9a5fe 17. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000015ed8bfd 18. /build/src/Storages/StorageReplicatedMergeTree.cpp:2514: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x0000000015ec9aab 19. /build/src/Storages/StorageReplicatedMergeTree.cpp:2349: DB::StorageReplicatedMergeTree::executeLogEntry(DB::ReplicatedMergeTreeLogEntry&) @ 0x0000000015eba91b 20. /build/src/Storages/StorageReplicatedMergeTree.cpp:3876: bool std::__function::__policy_invoker&)>::__call_impl[abi:se190107])::$_1, bool (std::shared_ptr&)>>(std::__function::__policy_storage const*, std::shared_ptr&) @ 0x0000000015f9837e 21. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000165d6fc3 22. /build/src/Storages/StorageReplicatedMergeTree.cpp:3872: DB::StorageReplicatedMergeTree::processQueueEntry(std::shared_ptr) @ 0x0000000015efc18a 23. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001624c1b2 24. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000162f9c70 25. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x00000000162fa55a 26. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc6653 27. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000000fccc4c3 28. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc3d92 29. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fcca080 30. ? @ 0x00007fbc6213eac3 31. ? @ 0x00007fbc621d0850 (version 25.3.6.10636.altinitytest (altinity build)) 2025.07.28 11:55:05.495799 [ 7399 ] {} ExternalDictionariesLoader: Could not load external dictionary 'cc8b1a52-da70-449c-9c23-8d623c5fcc44', next update is scheduled at 2025-07-28 11:58:40: Code: 396. DB::Exception: Limit for result exceeded, max bytes: 1.00 B, current bytes: 36.00 B. (TOO_MANY_ROWS_OR_BYTES), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, char const*&, ReadableSize&&, ReadableSize&&) @ 0x0000000013bd4eeb 4. /build/src/QueryPipeline/SizeLimits.cpp:43: DB::SizeLimits::check(unsigned long, unsigned long, char const*, int, int) const @ 0x0000000013bd48a1 5. /build/src/Processors/Transforms/LimitsCheckingTransform.cpp:45: DB::LimitsCheckingTransform::transform(DB::Chunk&) @ 0x0000000016c1d2fb 6. /build/src/Processors/ISimpleTransform.h:33: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000011a9a453 7. /build/src/Processors/ISimpleTransform.cpp:89: DB::ISimpleTransform::work() @ 0x000000001699fca0 8. /build/src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x00000000169bd00f 9. /build/src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x00000000169b2105 10. /build/src/Processors/Executors/PipelineExecutor.cpp:170: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x00000000169b16a7 11. /build/src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x00000000169c081c 12. /build/src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x00000000169c0978 13. /build/src/Dictionaries/FlatDictionary.cpp:502: DB::FlatDictionary::loadData() @ 0x0000000011b424cb 14. /build/src/Dictionaries/FlatDictionary.cpp:46: DB::FlatDictionary::FlatDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, DB::FlatDictionary::Configuration, std::shared_ptr) @ 0x0000000011b42111 15. /build/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:se190107]> (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) @ 0x0000000011b5d3e2 16. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000012d8a61d 17. /build/src/Interpreters/ExternalDictionariesLoader.cpp:47: DB::ExternalDictionariesLoader::createObject(String const&, Poco::Util::AbstractConfiguration const&, String const&, String const&) const @ 0x00000000148a6f44 18. /build/src/Interpreters/ExternalLoader.cpp:1522: DB::ExternalLoader::LoadingDispatcher::loadSingleObject(String const&, DB::ExternalLoader::ObjectConfig const&, std::shared_ptr) @ 0x00000000148b2ee8 19. /build/src/Interpreters/ExternalLoader.cpp:998: DB::ExternalLoader::LoadingDispatcher::doLoading(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr) @ 0x00000000148b197d 20. /build/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()() @ 0x00000000148b5991 21. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc3d92 22. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fcca080 23. ? @ 0x00007fbc6213eac3 24. ? @ 0x00007fbc621d0850 (version 25.3.6.10636.altinitytest (altinity build)) 2025.07.28 11:55:05.533707 [ 3969 ] {} test_13.rmt2 (7f9b740d-015c-470e-8cc6-8ba33be0dc63): auto DB::StorageReplicatedMergeTree::processQueueEntry(ReplicatedMergeTreeQueue::SelectedEntryPtr)::(anonymous class)::operator()(LogEntryPtr &) const: Code: 86. DB::HTTPException: Received error from remote server http://146b4357c08d:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Ftest%2F01165%2Ftest_13%2Frmt%2Freplicas%2F1&part=20250728_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.6.10636.altinitytest (altinity build)) '. (RECEIVED_ERROR_FROM_REMOTE_IO_SERVER), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.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 const&, int&&, String const&, unsigned long&&, String const&) @ 0x000000000feda8d9 4. /build/src/IO/HTTPCommon.cpp:104: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x000000000feda6e2 5. /build/src/IO/HTTPCommon.cpp:93: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x000000000feda537 6. /build/src/IO/ReadWriteBufferFromHTTP.cpp:277: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x000000001184a4c4 7. /build/src/IO/ReadWriteBufferFromHTTP.cpp:285: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x000000001184a615 8. /build/src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x000000001184ae59 9. /build/src/IO/ReadWriteBufferFromHTTP.cpp:472: void std::__function::__policy_invoker::__call_impl[abi:se190107]>(std::__function::__policy_storage const*) @ 0x000000001184cedd 10. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001184858b 11. /build/src/IO/ReadWriteBufferFromHTTP.cpp:465: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x000000001184bf0b 12. /build/src/IO/ReadBuffer.h:60: DB::ReadBuffer::next() @ 0x000000000a148c7b 13. /build/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) @ 0x0000000011849fb2 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]>&)>&, 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&) @ 0x0000000011841980 15. /build/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) @ 0x000000001621208e 16. /build/src/Storages/StorageReplicatedMergeTree.cpp:5228: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl[abi:se190107] const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000015f9a5fe 17. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000015ed8bfd 18. /build/src/Storages/StorageReplicatedMergeTree.cpp:2514: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x0000000015ec9aab 19. /build/src/Storages/StorageReplicatedMergeTree.cpp:2349: DB::StorageReplicatedMergeTree::executeLogEntry(DB::ReplicatedMergeTreeLogEntry&) @ 0x0000000015eba91b 20. /build/src/Storages/StorageReplicatedMergeTree.cpp:3876: bool std::__function::__policy_invoker&)>::__call_impl[abi:se190107])::$_1, bool (std::shared_ptr&)>>(std::__function::__policy_storage const*, std::shared_ptr&) @ 0x0000000015f9837e 21. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000165d6fc3 22. /build/src/Storages/StorageReplicatedMergeTree.cpp:3872: DB::StorageReplicatedMergeTree::processQueueEntry(std::shared_ptr) @ 0x0000000015efc18a 23. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001624c1b2 24. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000162f9c70 25. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x00000000162fa55a 26. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc6653 27. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000000fccc4c3 28. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc3d92 29. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fcca080 30. ? @ 0x00007fbc6213eac3 31. ? @ 0x00007fbc621d0850 (version 25.3.6.10636.altinitytest (altinity build)) 2025.07.28 11:55:05.727410 [ 3966 ] {} test_13.rmt2 (7f9b740d-015c-470e-8cc6-8ba33be0dc63): auto DB::StorageReplicatedMergeTree::processQueueEntry(ReplicatedMergeTreeQueue::SelectedEntryPtr)::(anonymous class)::operator()(LogEntryPtr &) const: Code: 86. DB::HTTPException: Received error from remote server http://146b4357c08d:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Ftest%2F01165%2Ftest_13%2Frmt%2Freplicas%2F1&part=20250728_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.6.10636.altinitytest (altinity build)) '. (RECEIVED_ERROR_FROM_REMOTE_IO_SERVER), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.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 const&, int&&, String const&, unsigned long&&, String const&) @ 0x000000000feda8d9 4. /build/src/IO/HTTPCommon.cpp:104: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x000000000feda6e2 5. /build/src/IO/HTTPCommon.cpp:93: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x000000000feda537 6. /build/src/IO/ReadWriteBufferFromHTTP.cpp:277: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x000000001184a4c4 7. /build/src/IO/ReadWriteBufferFromHTTP.cpp:285: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x000000001184a615 8. /build/src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x000000001184ae59 9. /build/src/IO/ReadWriteBufferFromHTTP.cpp:472: void std::__function::__policy_invoker::__call_impl[abi:se190107]>(std::__function::__policy_storage const*) @ 0x000000001184cedd 10. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001184858b 11. /build/src/IO/ReadWriteBufferFromHTTP.cpp:465: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x000000001184bf0b 12. /build/src/IO/ReadBuffer.h:60: DB::ReadBuffer::next() @ 0x000000000a148c7b 13. /build/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) @ 0x0000000011849fb2 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]>&)>&, 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&) @ 0x0000000011841980 15. /build/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) @ 0x000000001621208e 16. /build/src/Storages/StorageReplicatedMergeTree.cpp:5228: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl[abi:se190107] const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000015f9a5fe 17. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000015ed8bfd 18. /build/src/Storages/StorageReplicatedMergeTree.cpp:2514: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x0000000015ec9aab 19. /build/src/Storages/StorageReplicatedMergeTree.cpp:2349: DB::StorageReplicatedMergeTree::executeLogEntry(DB::ReplicatedMergeTreeLogEntry&) @ 0x0000000015eba91b 20. /build/src/Storages/StorageReplicatedMergeTree.cpp:3876: bool std::__function::__policy_invoker&)>::__call_impl[abi:se190107])::$_1, bool (std::shared_ptr&)>>(std::__function::__policy_storage const*, std::shared_ptr&) @ 0x0000000015f9837e 21. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000165d6fc3 22. /build/src/Storages/StorageReplicatedMergeTree.cpp:3872: DB::StorageReplicatedMergeTree::processQueueEntry(std::shared_ptr) @ 0x0000000015efc18a 23. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001624c1b2 24. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000162f9c70 25. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x00000000162fa55a 26. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc6653 27. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000000fccc4c3 28. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc3d92 29. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fcca080 30. ? @ 0x00007fbc6213eac3 31. ? @ 0x00007fbc621d0850 (version 25.3.6.10636.altinitytest (altinity build)) 2025.07.28 11:55:05.909963 [ 17321 ] {278b5ff7-1dfa-4647-bac5-243ff53fcf7c} executeQuery: Code: 57. DB::Exception: Table test_5.t1 already exists. (TABLE_ALREADY_EXISTS) (version 25.3.6.10636.altinitytest (altinity build)) (from 0.0.0.0:0) (comment: 03302_analyzer_join_filter_push_down_bug.sql) (in query: /* ddl_entry=query-0000000110 */ CREATE TABLE test_5.t1 UUID '67bea74f-0e68-4feb-8264-06b296f58311' (`key` Int32, `value` DateTime) ENGINE = Log), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000a06a8eb 4. /build/src/Interpreters/InterpreterCreateQuery.cpp:1824: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x0000000014901d53 5. /build/src/Interpreters/InterpreterCreateQuery.cpp:1743: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000148f9aa9 6. /build/src/Interpreters/InterpreterCreateQuery.cpp:2352: DB::InterpreterCreateQuery::execute() @ 0x0000000014905a41 7. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88dc9 8. /build/src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x0000000014c8ca7b 9. /build/src/Interpreters/DDLWorker.cpp:510: DB::DDLWorker::tryExecuteQuery(DB::DDLTaskBase&, std::shared_ptr const&, bool) @ 0x00000000144dab9e 10. /build/src/Interpreters/DDLWorker.cpp:675: DB::DDLWorker::processTask(DB::DDLTaskBase&, std::shared_ptr const&, bool) @ 0x00000000144d8ffe 11. /build/src/Databases/DatabaseReplicatedWorker.cpp:372: DB::DatabaseReplicatedDDLWorker::tryEnqueueAndExecuteEntry(DB::DDLLogEntry&, std::shared_ptr, bool) @ 0x0000000013dc29ab 12. /build/src/Databases/DatabaseReplicated.cpp:1139: DB::DatabaseReplicated::tryEnqueueReplicatedDDL(std::shared_ptr const&, std::shared_ptr, DB::QueryFlags) @ 0x0000000013d9f73c 13. /build/src/Interpreters/InterpreterCreateQuery.cpp:1723: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000148f96f8 14. /build/src/Interpreters/InterpreterCreateQuery.cpp:2352: DB::InterpreterCreateQuery::execute() @ 0x0000000014905a41 15. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88dc9 16. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 17. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 18. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 19. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 20. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 21. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 22. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 23. ? @ 0x00007fbc6213eac3 24. ? @ 0x00007fbc621d0850 2025.07.28 11:55:05.928827 [ 17321 ] {278b5ff7-1dfa-4647-bac5-243ff53fcf7c} executeQuery: Code: 57. DB::Exception: Table test_5.t1 already exists. (TABLE_ALREADY_EXISTS) (version 25.3.6.10636.altinitytest (altinity build)) (from [::1]:38710) (comment: 03302_analyzer_join_filter_push_down_bug.sql) (query 1, line 1) (in query: CREATE TABLE t1 (key Int32, value DateTime) ENGINE = Log;), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000a06a8eb 4. /build/src/Interpreters/InterpreterCreateQuery.cpp:1824: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x0000000014901d53 5. /build/src/Interpreters/InterpreterCreateQuery.cpp:1743: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000148f9aa9 6. /build/src/Interpreters/InterpreterCreateQuery.cpp:2352: DB::InterpreterCreateQuery::execute() @ 0x0000000014905a41 7. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88dc9 8. /build/src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x0000000014c8ca7b 9. /build/src/Interpreters/DDLWorker.cpp:510: DB::DDLWorker::tryExecuteQuery(DB::DDLTaskBase&, std::shared_ptr const&, bool) @ 0x00000000144dab9e 10. /build/src/Interpreters/DDLWorker.cpp:675: DB::DDLWorker::processTask(DB::DDLTaskBase&, std::shared_ptr const&, bool) @ 0x00000000144d8ffe 11. /build/src/Databases/DatabaseReplicatedWorker.cpp:372: DB::DatabaseReplicatedDDLWorker::tryEnqueueAndExecuteEntry(DB::DDLLogEntry&, std::shared_ptr, bool) @ 0x0000000013dc29ab 12. /build/src/Databases/DatabaseReplicated.cpp:1139: DB::DatabaseReplicated::tryEnqueueReplicatedDDL(std::shared_ptr const&, std::shared_ptr, DB::QueryFlags) @ 0x0000000013d9f73c 13. /build/src/Interpreters/InterpreterCreateQuery.cpp:1723: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000148f96f8 14. /build/src/Interpreters/InterpreterCreateQuery.cpp:2352: DB::InterpreterCreateQuery::execute() @ 0x0000000014905a41 15. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88dc9 16. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 17. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 18. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 19. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 20. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 21. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 22. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 23. ? @ 0x00007fbc6213eac3 24. ? @ 0x00007fbc621d0850 2025.07.28 11:55:05.936254 [ 17321 ] {} TCPHandler: Code: 57. DB::Exception: Table test_5.t1 already exists. (TABLE_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000a06a8eb 4. /build/src/Interpreters/InterpreterCreateQuery.cpp:1824: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x0000000014901d53 5. /build/src/Interpreters/InterpreterCreateQuery.cpp:1743: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000148f9aa9 6. /build/src/Interpreters/InterpreterCreateQuery.cpp:2352: DB::InterpreterCreateQuery::execute() @ 0x0000000014905a41 7. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88dc9 8. /build/src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x0000000014c8ca7b 9. /build/src/Interpreters/DDLWorker.cpp:510: DB::DDLWorker::tryExecuteQuery(DB::DDLTaskBase&, std::shared_ptr const&, bool) @ 0x00000000144dab9e 10. /build/src/Interpreters/DDLWorker.cpp:675: DB::DDLWorker::processTask(DB::DDLTaskBase&, std::shared_ptr const&, bool) @ 0x00000000144d8ffe 11. /build/src/Databases/DatabaseReplicatedWorker.cpp:372: DB::DatabaseReplicatedDDLWorker::tryEnqueueAndExecuteEntry(DB::DDLLogEntry&, std::shared_ptr, bool) @ 0x0000000013dc29ab 12. /build/src/Databases/DatabaseReplicated.cpp:1139: DB::DatabaseReplicated::tryEnqueueReplicatedDDL(std::shared_ptr const&, std::shared_ptr, DB::QueryFlags) @ 0x0000000013d9f73c 13. /build/src/Interpreters/InterpreterCreateQuery.cpp:1723: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000148f96f8 14. /build/src/Interpreters/InterpreterCreateQuery.cpp:2352: DB::InterpreterCreateQuery::execute() @ 0x0000000014905a41 15. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88dc9 16. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 17. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 18. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 19. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 20. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 21. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 22. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 23. ? @ 0x00007fbc6213eac3 24. ? @ 0x00007fbc621d0850 2025.07.28 11:55:06.356349 [ 3962 ] {} test_13.rmt2 (7f9b740d-015c-470e-8cc6-8ba33be0dc63): auto DB::StorageReplicatedMergeTree::processQueueEntry(ReplicatedMergeTreeQueue::SelectedEntryPtr)::(anonymous class)::operator()(LogEntryPtr &) const: Code: 86. DB::HTTPException: Received error from remote server http://146b4357c08d:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Ftest%2F01165%2Ftest_13%2Frmt%2Freplicas%2F1&part=20250728_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.6.10636.altinitytest (altinity build)) '. (RECEIVED_ERROR_FROM_REMOTE_IO_SERVER), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.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 const&, int&&, String const&, unsigned long&&, String const&) @ 0x000000000feda8d9 4. /build/src/IO/HTTPCommon.cpp:104: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x000000000feda6e2 5. /build/src/IO/HTTPCommon.cpp:93: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x000000000feda537 6. /build/src/IO/ReadWriteBufferFromHTTP.cpp:277: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x000000001184a4c4 7. /build/src/IO/ReadWriteBufferFromHTTP.cpp:285: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x000000001184a615 8. /build/src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x000000001184ae59 9. /build/src/IO/ReadWriteBufferFromHTTP.cpp:472: void std::__function::__policy_invoker::__call_impl[abi:se190107]>(std::__function::__policy_storage const*) @ 0x000000001184cedd 10. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001184858b 11. /build/src/IO/ReadWriteBufferFromHTTP.cpp:465: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x000000001184bf0b 12. /build/src/IO/ReadBuffer.h:60: DB::ReadBuffer::next() @ 0x000000000a148c7b 13. /build/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) @ 0x0000000011849fb2 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]>&)>&, 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&) @ 0x0000000011841980 15. /build/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) @ 0x000000001621208e 16. /build/src/Storages/StorageReplicatedMergeTree.cpp:5228: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl[abi:se190107] const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000015f9a5fe 17. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000015ed8bfd 18. /build/src/Storages/StorageReplicatedMergeTree.cpp:2514: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x0000000015ec9aab 19. /build/src/Storages/StorageReplicatedMergeTree.cpp:2349: DB::StorageReplicatedMergeTree::executeLogEntry(DB::ReplicatedMergeTreeLogEntry&) @ 0x0000000015eba91b 20. /build/src/Storages/StorageReplicatedMergeTree.cpp:3876: bool std::__function::__policy_invoker&)>::__call_impl[abi:se190107])::$_1, bool (std::shared_ptr&)>>(std::__function::__policy_storage const*, std::shared_ptr&) @ 0x0000000015f9837e 21. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000165d6fc3 22. /build/src/Storages/StorageReplicatedMergeTree.cpp:3872: DB::StorageReplicatedMergeTree::processQueueEntry(std::shared_ptr) @ 0x0000000015efc18a 23. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001624c1b2 24. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000162f9c70 25. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x00000000162fa55a 26. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc6653 27. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000000fccc4c3 28. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc3d92 29. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fcca080 30. ? @ 0x00007fbc6213eac3 31. ? @ 0x00007fbc621d0850 (version 25.3.6.10636.altinitytest (altinity build)) 2025.07.28 11:55:07.285817 [ 3968 ] {} test_13.rmt2 (7f9b740d-015c-470e-8cc6-8ba33be0dc63): auto DB::StorageReplicatedMergeTree::processQueueEntry(ReplicatedMergeTreeQueue::SelectedEntryPtr)::(anonymous class)::operator()(LogEntryPtr &) const: Code: 86. DB::HTTPException: Received error from remote server http://146b4357c08d:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Ftest%2F01165%2Ftest_13%2Frmt%2Freplicas%2F1&part=20250728_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.6.10636.altinitytest (altinity build)) '. (RECEIVED_ERROR_FROM_REMOTE_IO_SERVER), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.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 const&, int&&, String const&, unsigned long&&, String const&) @ 0x000000000feda8d9 4. /build/src/IO/HTTPCommon.cpp:104: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x000000000feda6e2 5. /build/src/IO/HTTPCommon.cpp:93: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x000000000feda537 6. /build/src/IO/ReadWriteBufferFromHTTP.cpp:277: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x000000001184a4c4 7. /build/src/IO/ReadWriteBufferFromHTTP.cpp:285: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x000000001184a615 8. /build/src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x000000001184ae59 9. /build/src/IO/ReadWriteBufferFromHTTP.cpp:472: void std::__function::__policy_invoker::__call_impl[abi:se190107]>(std::__function::__policy_storage const*) @ 0x000000001184cedd 10. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001184858b 11. /build/src/IO/ReadWriteBufferFromHTTP.cpp:465: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x000000001184bf0b 12. /build/src/IO/ReadBuffer.h:60: DB::ReadBuffer::next() @ 0x000000000a148c7b 13. /build/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) @ 0x0000000011849fb2 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]>&)>&, 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&) @ 0x0000000011841980 15. /build/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) @ 0x000000001621208e 16. /build/src/Storages/StorageReplicatedMergeTree.cpp:5228: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl[abi:se190107] const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000015f9a5fe 17. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000015ed8bfd 18. /build/src/Storages/StorageReplicatedMergeTree.cpp:2514: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x0000000015ec9aab 19. /build/src/Storages/StorageReplicatedMergeTree.cpp:2349: DB::StorageReplicatedMergeTree::executeLogEntry(DB::ReplicatedMergeTreeLogEntry&) @ 0x0000000015eba91b 20. /build/src/Storages/StorageReplicatedMergeTree.cpp:3876: bool std::__function::__policy_invoker&)>::__call_impl[abi:se190107])::$_1, bool (std::shared_ptr&)>>(std::__function::__policy_storage const*, std::shared_ptr&) @ 0x0000000015f9837e 21. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000165d6fc3 22. /build/src/Storages/StorageReplicatedMergeTree.cpp:3872: DB::StorageReplicatedMergeTree::processQueueEntry(std::shared_ptr) @ 0x0000000015efc18a 23. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001624c1b2 24. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000162f9c70 25. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x00000000162fa55a 26. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc6653 27. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000000fccc4c3 28. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc3d92 29. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fcca080 30. ? @ 0x00007fbc6213eac3 31. ? @ 0x00007fbc621d0850 (version 25.3.6.10636.altinitytest (altinity build)) 2025.07.28 11:55:07.450490 [ 17321 ] {f2e7b6ad-dd08-4263-adb9-ee3bb9677b2f} executeQuery: Code: 47. DB::Exception: Missing columns: 'All' while processing: '`All`', required columns: 'All', available columns: 'id'. (UNKNOWN_IDENTIFIER) (version 25.3.6.10636.altinitytest (altinity build)) (from 0.0.0.0:0) (comment: 03316_fixup_used_columns_exception.sh) (in query: /* ddl_entry=query-0000000111 */ CREATE TABLE test_5.test_exception UUID 'd92a3af2-be37-4f65-866b-60f23ff451a2' (`id` UInt64) ENGINE = MergeTree ORDER BY `All` SETTINGS index_granularity = 18091, min_bytes_for_wide_part = 0, ratio_of_defaults_for_sparse_serialization = 0.7000688910484314, 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 = 31857567, compact_parts_max_granules_to_buffer = 222, compact_parts_merge_max_bytes_to_prefetch_part = 32769888, merge_max_block_size = 4325, old_parts_lifetime = 229., prefer_fetch_merged_part_size_threshold = 10213023668, vertical_merge_algorithm_min_rows_to_activate = 1000000, vertical_merge_algorithm_min_columns_to_activate = 69, min_merge_bytes_to_use_direct_io = 10737418240, index_granularity_bytes = 24677127, use_const_adaptive_granularity = true, enable_index_granularity_compression = false, concurrent_part_removal_threshold = 63, allow_vertical_merges_from_compact_to_wide_parts = true, enable_block_number_column = true, enable_block_offset_column = true, cache_populated_by_fetch = false, marks_compress_block_size = 72008, primary_key_compress_block_size = 91064, 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. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Interpreters/TreeRewriter.cpp:1303: DB::TreeRewriterResult::collectUsedColumns(std::shared_ptr const&, bool, bool) @ 0x0000000014c01fc8 4. /build/src/Interpreters/TreeRewriter.cpp:1561: DB::TreeRewriter::analyze(std::shared_ptr&, DB::NamesAndTypesList const&, std::shared_ptr, std::shared_ptr const&, bool, bool, bool, bool) const @ 0x0000000014c0a438 5. /build/src/Storages/KeyDescription.cpp:163: DB::KeyDescription::getSortingKeyFromAST(std::shared_ptr const&, DB::ColumnsDescription const&, std::shared_ptr, std::optional const&) @ 0x0000000015d2e395 6. /build/src/Storages/MergeTree/registerStorageMergeTree.cpp:668: DB::create(DB::StorageFactory::Arguments const&) @ 0x000000001662daa0 7. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000015d81ea2 8. /build/src/Interpreters/InterpreterCreateQuery.cpp:1945: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x00000000149009bb 9. /build/src/Interpreters/InterpreterCreateQuery.cpp:1743: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000148f9aa9 10. /build/src/Interpreters/InterpreterCreateQuery.cpp:2352: DB::InterpreterCreateQuery::execute() @ 0x0000000014905a41 11. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88dc9 12. /build/src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x0000000014c8ca7b 13. /build/src/Interpreters/DDLWorker.cpp:510: DB::DDLWorker::tryExecuteQuery(DB::DDLTaskBase&, std::shared_ptr const&, bool) @ 0x00000000144dab9e 14. /build/src/Interpreters/DDLWorker.cpp:675: DB::DDLWorker::processTask(DB::DDLTaskBase&, std::shared_ptr const&, bool) @ 0x00000000144d8ffe 15. /build/src/Databases/DatabaseReplicatedWorker.cpp:372: DB::DatabaseReplicatedDDLWorker::tryEnqueueAndExecuteEntry(DB::DDLLogEntry&, std::shared_ptr, bool) @ 0x0000000013dc29ab 16. /build/src/Databases/DatabaseReplicated.cpp:1139: DB::DatabaseReplicated::tryEnqueueReplicatedDDL(std::shared_ptr const&, std::shared_ptr, DB::QueryFlags) @ 0x0000000013d9f73c 17. /build/src/Interpreters/InterpreterCreateQuery.cpp:1723: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000148f96f8 18. /build/src/Interpreters/InterpreterCreateQuery.cpp:2352: DB::InterpreterCreateQuery::execute() @ 0x0000000014905a41 19. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88dc9 20. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 21. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 22. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 23. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 24. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 25. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 26. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 27. ? @ 0x00007fbc6213eac3 28. ? @ 0x00007fbc621d0850 2025.07.28 11:55:07.484124 [ 17321 ] {f2e7b6ad-dd08-4263-adb9-ee3bb9677b2f} executeQuery: Code: 47. DB::Exception: Missing columns: 'All' while processing: '`All`', required columns: 'All', available columns: 'id'. (UNKNOWN_IDENTIFIER) (version 25.3.6.10636.altinitytest (altinity build)) (from [::1]:38726) (comment: 03316_fixup_used_columns_exception.sh) (query 1, line 2) (in query: CREATE TABLE test_exception (`id` UInt64) ENGINE = MergeTree ORDER BY `All` SETTINGS index_granularity = 18091, min_bytes_for_wide_part = 0, ratio_of_defaults_for_sparse_serialization = 0.7000688910484314, 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 = 31857567, compact_parts_max_granules_to_buffer = 222, compact_parts_merge_max_bytes_to_prefetch_part = 32769888, merge_max_block_size = 4325, old_parts_lifetime = 229., prefer_fetch_merged_part_size_threshold = 10213023668, vertical_merge_algorithm_min_rows_to_activate = 1000000, vertical_merge_algorithm_min_columns_to_activate = 69, min_merge_bytes_to_use_direct_io = 10737418240, index_granularity_bytes = 24677127, use_const_adaptive_granularity = true, enable_index_granularity_compression = false, concurrent_part_removal_threshold = 63, allow_vertical_merges_from_compact_to_wide_parts = true, enable_block_number_column = true, enable_block_offset_column = true, cache_populated_by_fetch = false, marks_compress_block_size = 72008, primary_key_compress_block_size = 91064, 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. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Interpreters/TreeRewriter.cpp:1303: DB::TreeRewriterResult::collectUsedColumns(std::shared_ptr const&, bool, bool) @ 0x0000000014c01fc8 4. /build/src/Interpreters/TreeRewriter.cpp:1561: DB::TreeRewriter::analyze(std::shared_ptr&, DB::NamesAndTypesList const&, std::shared_ptr, std::shared_ptr const&, bool, bool, bool, bool) const @ 0x0000000014c0a438 5. /build/src/Storages/KeyDescription.cpp:163: DB::KeyDescription::getSortingKeyFromAST(std::shared_ptr const&, DB::ColumnsDescription const&, std::shared_ptr, std::optional const&) @ 0x0000000015d2e395 6. /build/src/Storages/MergeTree/registerStorageMergeTree.cpp:668: DB::create(DB::StorageFactory::Arguments const&) @ 0x000000001662daa0 7. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000015d81ea2 8. /build/src/Interpreters/InterpreterCreateQuery.cpp:1945: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x00000000149009bb 9. /build/src/Interpreters/InterpreterCreateQuery.cpp:1743: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000148f9aa9 10. /build/src/Interpreters/InterpreterCreateQuery.cpp:2352: DB::InterpreterCreateQuery::execute() @ 0x0000000014905a41 11. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88dc9 12. /build/src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x0000000014c8ca7b 13. /build/src/Interpreters/DDLWorker.cpp:510: DB::DDLWorker::tryExecuteQuery(DB::DDLTaskBase&, std::shared_ptr const&, bool) @ 0x00000000144dab9e 14. /build/src/Interpreters/DDLWorker.cpp:675: DB::DDLWorker::processTask(DB::DDLTaskBase&, std::shared_ptr const&, bool) @ 0x00000000144d8ffe 15. /build/src/Databases/DatabaseReplicatedWorker.cpp:372: DB::DatabaseReplicatedDDLWorker::tryEnqueueAndExecuteEntry(DB::DDLLogEntry&, std::shared_ptr, bool) @ 0x0000000013dc29ab 16. /build/src/Databases/DatabaseReplicated.cpp:1139: DB::DatabaseReplicated::tryEnqueueReplicatedDDL(std::shared_ptr const&, std::shared_ptr, DB::QueryFlags) @ 0x0000000013d9f73c 17. /build/src/Interpreters/InterpreterCreateQuery.cpp:1723: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000148f96f8 18. /build/src/Interpreters/InterpreterCreateQuery.cpp:2352: DB::InterpreterCreateQuery::execute() @ 0x0000000014905a41 19. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88dc9 20. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 21. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 22. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 23. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 24. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 25. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 26. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 27. ? @ 0x00007fbc6213eac3 28. ? @ 0x00007fbc621d0850 2025.07.28 11:55:07.506903 [ 17321 ] {} TCPHandler: Code: 47. DB::Exception: Missing columns: 'All' while processing: '`All`', required columns: 'All', available columns: 'id'. (UNKNOWN_IDENTIFIER), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Interpreters/TreeRewriter.cpp:1303: DB::TreeRewriterResult::collectUsedColumns(std::shared_ptr const&, bool, bool) @ 0x0000000014c01fc8 4. /build/src/Interpreters/TreeRewriter.cpp:1561: DB::TreeRewriter::analyze(std::shared_ptr&, DB::NamesAndTypesList const&, std::shared_ptr, std::shared_ptr const&, bool, bool, bool, bool) const @ 0x0000000014c0a438 5. /build/src/Storages/KeyDescription.cpp:163: DB::KeyDescription::getSortingKeyFromAST(std::shared_ptr const&, DB::ColumnsDescription const&, std::shared_ptr, std::optional const&) @ 0x0000000015d2e395 6. /build/src/Storages/MergeTree/registerStorageMergeTree.cpp:668: DB::create(DB::StorageFactory::Arguments const&) @ 0x000000001662daa0 7. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000015d81ea2 8. /build/src/Interpreters/InterpreterCreateQuery.cpp:1945: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x00000000149009bb 9. /build/src/Interpreters/InterpreterCreateQuery.cpp:1743: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000148f9aa9 10. /build/src/Interpreters/InterpreterCreateQuery.cpp:2352: DB::InterpreterCreateQuery::execute() @ 0x0000000014905a41 11. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88dc9 12. /build/src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x0000000014c8ca7b 13. /build/src/Interpreters/DDLWorker.cpp:510: DB::DDLWorker::tryExecuteQuery(DB::DDLTaskBase&, std::shared_ptr const&, bool) @ 0x00000000144dab9e 14. /build/src/Interpreters/DDLWorker.cpp:675: DB::DDLWorker::processTask(DB::DDLTaskBase&, std::shared_ptr const&, bool) @ 0x00000000144d8ffe 15. /build/src/Databases/DatabaseReplicatedWorker.cpp:372: DB::DatabaseReplicatedDDLWorker::tryEnqueueAndExecuteEntry(DB::DDLLogEntry&, std::shared_ptr, bool) @ 0x0000000013dc29ab 16. /build/src/Databases/DatabaseReplicated.cpp:1139: DB::DatabaseReplicated::tryEnqueueReplicatedDDL(std::shared_ptr const&, std::shared_ptr, DB::QueryFlags) @ 0x0000000013d9f73c 17. /build/src/Interpreters/InterpreterCreateQuery.cpp:1723: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000148f96f8 18. /build/src/Interpreters/InterpreterCreateQuery.cpp:2352: DB::InterpreterCreateQuery::execute() @ 0x0000000014905a41 19. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88dc9 20. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 21. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 22. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 23. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 24. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 25. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 26. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 27. ? @ 0x00007fbc6213eac3 28. ? @ 0x00007fbc621d0850 2025.07.28 11:55:07.615825 [ 3976 ] {} test_13.rmt2 (7f9b740d-015c-470e-8cc6-8ba33be0dc63): auto DB::StorageReplicatedMergeTree::processQueueEntry(ReplicatedMergeTreeQueue::SelectedEntryPtr)::(anonymous class)::operator()(LogEntryPtr &) const: Code: 86. DB::HTTPException: Received error from remote server http://146b4357c08d:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Ftest%2F01165%2Ftest_13%2Frmt%2Freplicas%2F1&part=20250728_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.6.10636.altinitytest (altinity build)) '. (RECEIVED_ERROR_FROM_REMOTE_IO_SERVER), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.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 const&, int&&, String const&, unsigned long&&, String const&) @ 0x000000000feda8d9 4. /build/src/IO/HTTPCommon.cpp:104: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x000000000feda6e2 5. /build/src/IO/HTTPCommon.cpp:93: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x000000000feda537 6. /build/src/IO/ReadWriteBufferFromHTTP.cpp:277: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x000000001184a4c4 7. /build/src/IO/ReadWriteBufferFromHTTP.cpp:285: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x000000001184a615 8. /build/src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x000000001184ae59 9. /build/src/IO/ReadWriteBufferFromHTTP.cpp:472: void std::__function::__policy_invoker::__call_impl[abi:se190107]>(std::__function::__policy_storage const*) @ 0x000000001184cedd 10. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001184858b 11. /build/src/IO/ReadWriteBufferFromHTTP.cpp:465: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x000000001184bf0b 12. /build/src/IO/ReadBuffer.h:60: DB::ReadBuffer::next() @ 0x000000000a148c7b 13. /build/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) @ 0x0000000011849fb2 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]>&)>&, 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&) @ 0x0000000011841980 15. /build/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) @ 0x000000001621208e 16. /build/src/Storages/StorageReplicatedMergeTree.cpp:5228: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl[abi:se190107] const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000015f9a5fe 17. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000015ed8bfd 18. /build/src/Storages/StorageReplicatedMergeTree.cpp:2514: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x0000000015ec9aab 19. /build/src/Storages/StorageReplicatedMergeTree.cpp:2349: DB::StorageReplicatedMergeTree::executeLogEntry(DB::ReplicatedMergeTreeLogEntry&) @ 0x0000000015eba91b 20. /build/src/Storages/StorageReplicatedMergeTree.cpp:3876: bool std::__function::__policy_invoker&)>::__call_impl[abi:se190107])::$_1, bool (std::shared_ptr&)>>(std::__function::__policy_storage const*, std::shared_ptr&) @ 0x0000000015f9837e 21. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000165d6fc3 22. /build/src/Storages/StorageReplicatedMergeTree.cpp:3872: DB::StorageReplicatedMergeTree::processQueueEntry(std::shared_ptr) @ 0x0000000015efc18a 23. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001624c1b2 24. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000162f9c70 25. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x00000000162fa55a 26. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc6653 27. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000000fccc4c3 28. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc3d92 29. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fcca080 30. ? @ 0x00007fbc6213eac3 31. ? @ 0x00007fbc621d0850 (version 25.3.6.10636.altinitytest (altinity build)) 2025.07.28 11:55:08.093684 [ 3965 ] {} test_13.rmt2 (7f9b740d-015c-470e-8cc6-8ba33be0dc63): auto DB::StorageReplicatedMergeTree::processQueueEntry(ReplicatedMergeTreeQueue::SelectedEntryPtr)::(anonymous class)::operator()(LogEntryPtr &) const: Code: 86. DB::HTTPException: Received error from remote server http://146b4357c08d:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Ftest%2F01165%2Ftest_13%2Frmt%2Freplicas%2F1&part=20250728_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.6.10636.altinitytest (altinity build)) '. (RECEIVED_ERROR_FROM_REMOTE_IO_SERVER), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.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 const&, int&&, String const&, unsigned long&&, String const&) @ 0x000000000feda8d9 4. /build/src/IO/HTTPCommon.cpp:104: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x000000000feda6e2 5. /build/src/IO/HTTPCommon.cpp:93: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x000000000feda537 6. /build/src/IO/ReadWriteBufferFromHTTP.cpp:277: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x000000001184a4c4 7. /build/src/IO/ReadWriteBufferFromHTTP.cpp:285: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x000000001184a615 8. /build/src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x000000001184ae59 9. /build/src/IO/ReadWriteBufferFromHTTP.cpp:472: void std::__function::__policy_invoker::__call_impl[abi:se190107]>(std::__function::__policy_storage const*) @ 0x000000001184cedd 10. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001184858b 11. /build/src/IO/ReadWriteBufferFromHTTP.cpp:465: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x000000001184bf0b 12. /build/src/IO/ReadBuffer.h:60: DB::ReadBuffer::next() @ 0x000000000a148c7b 13. /build/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) @ 0x0000000011849fb2 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]>&)>&, 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&) @ 0x0000000011841980 15. /build/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) @ 0x000000001621208e 16. /build/src/Storages/StorageReplicatedMergeTree.cpp:5228: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl[abi:se190107] const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000015f9a5fe 17. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000015ed8bfd 18. /build/src/Storages/StorageReplicatedMergeTree.cpp:2514: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x0000000015ec9aab 19. /build/src/Storages/StorageReplicatedMergeTree.cpp:2349: DB::StorageReplicatedMergeTree::executeLogEntry(DB::ReplicatedMergeTreeLogEntry&) @ 0x0000000015eba91b 20. /build/src/Storages/StorageReplicatedMergeTree.cpp:3876: bool std::__function::__policy_invoker&)>::__call_impl[abi:se190107])::$_1, bool (std::shared_ptr&)>>(std::__function::__policy_storage const*, std::shared_ptr&) @ 0x0000000015f9837e 21. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000165d6fc3 22. /build/src/Storages/StorageReplicatedMergeTree.cpp:3872: DB::StorageReplicatedMergeTree::processQueueEntry(std::shared_ptr) @ 0x0000000015efc18a 23. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001624c1b2 24. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000162f9c70 25. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x00000000162fa55a 26. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc6653 27. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000000fccc4c3 28. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc3d92 29. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fcca080 30. ? @ 0x00007fbc6213eac3 31. ? @ 0x00007fbc621d0850 (version 25.3.6.10636.altinitytest (altinity build)) 2025.07.28 11:55:08.216222 [ 17321 ] {deb63d05-37f0-4433-a6d1-863b55b8982a} executeQuery: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=835, jobs=803). (CANNOT_SCHEDULE_TASK) (version 25.3.6.10636.altinitytest (altinity build)) (from [::1]:38750) (comment: 00386_has_column_in_table.sql) (query 6, line 8) (in query: SELECT hasColumnInTable('localhost', currentDatabase(), 'has_column_in_table', 's');), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000fccaeeb 4. /build/src/Common/ThreadPool.cpp:275: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000fccacb3 5. /build/src/Common/ThreadPool.cpp:323: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fcc4ffc 6. /build/src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000000fcc584d 7. /build/src/Common/ThreadPool.h:279: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x00000000169bf193 8. /build/src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x00000000169bf518 9. /build/src/Server/TCPHandler.cpp:1237: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x00000000168f1525 10. /build/src/Server/TCPHandler.cpp:678: DB::TCPHandler::runImpl() @ 0x00000000168e68e5 11. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 12. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 13. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 14. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 15. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 16. ? @ 0x00007fbc6213eac3 17. ? @ 0x00007fbc621d0850 2025.07.28 11:55:08.226529 [ 17321 ] {} TCPHandler: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=835, jobs=803). (CANNOT_SCHEDULE_TASK), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000fccaeeb 4. /build/src/Common/ThreadPool.cpp:275: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000fccacb3 5. /build/src/Common/ThreadPool.cpp:323: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fcc4ffc 6. /build/src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000000fcc584d 7. /build/src/Common/ThreadPool.h:279: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x00000000169bf193 8. /build/src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x00000000169bf518 9. /build/src/Server/TCPHandler.cpp:1237: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x00000000168f1525 10. /build/src/Server/TCPHandler.cpp:678: DB::TCPHandler::runImpl() @ 0x00000000168e68e5 11. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 12. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 13. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 14. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 15. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 16. ? @ 0x00007fbc6213eac3 17. ? @ 0x00007fbc621d0850 2025.07.28 11:55:09.007185 [ 3962 ] {} test_13.rmt2 (7f9b740d-015c-470e-8cc6-8ba33be0dc63): auto DB::StorageReplicatedMergeTree::processQueueEntry(ReplicatedMergeTreeQueue::SelectedEntryPtr)::(anonymous class)::operator()(LogEntryPtr &) const: Code: 86. DB::HTTPException: Received error from remote server http://146b4357c08d:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Ftest%2F01165%2Ftest_13%2Frmt%2Freplicas%2F1&part=20250728_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.6.10636.altinitytest (altinity build)) '. (RECEIVED_ERROR_FROM_REMOTE_IO_SERVER), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.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 const&, int&&, String const&, unsigned long&&, String const&) @ 0x000000000feda8d9 4. /build/src/IO/HTTPCommon.cpp:104: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x000000000feda6e2 5. /build/src/IO/HTTPCommon.cpp:93: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x000000000feda537 6. /build/src/IO/ReadWriteBufferFromHTTP.cpp:277: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x000000001184a4c4 7. /build/src/IO/ReadWriteBufferFromHTTP.cpp:285: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x000000001184a615 8. /build/src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x000000001184ae59 9. /build/src/IO/ReadWriteBufferFromHTTP.cpp:472: void std::__function::__policy_invoker::__call_impl[abi:se190107]>(std::__function::__policy_storage const*) @ 0x000000001184cedd 10. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001184858b 11. /build/src/IO/ReadWriteBufferFromHTTP.cpp:465: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x000000001184bf0b 12. /build/src/IO/ReadBuffer.h:60: DB::ReadBuffer::next() @ 0x000000000a148c7b 13. /build/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) @ 0x0000000011849fb2 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]>&)>&, 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&) @ 0x0000000011841980 15. /build/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) @ 0x000000001621208e 16. /build/src/Storages/StorageReplicatedMergeTree.cpp:5228: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl[abi:se190107] const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000015f9a5fe 17. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000015ed8bfd 18. /build/src/Storages/StorageReplicatedMergeTree.cpp:2514: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x0000000015ec9aab 19. /build/src/Storages/StorageReplicatedMergeTree.cpp:2349: DB::StorageReplicatedMergeTree::executeLogEntry(DB::ReplicatedMergeTreeLogEntry&) @ 0x0000000015eba91b 20. /build/src/Storages/StorageReplicatedMergeTree.cpp:3876: bool std::__function::__policy_invoker&)>::__call_impl[abi:se190107])::$_1, bool (std::shared_ptr&)>>(std::__function::__policy_storage const*, std::shared_ptr&) @ 0x0000000015f9837e 21. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000165d6fc3 22. /build/src/Storages/StorageReplicatedMergeTree.cpp:3872: DB::StorageReplicatedMergeTree::processQueueEntry(std::shared_ptr) @ 0x0000000015efc18a 23. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001624c1b2 24. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000162f9c70 25. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x00000000162fa55a 26. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc6653 27. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000000fccc4c3 28. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc3d92 29. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fcca080 30. ? @ 0x00007fbc6213eac3 31. ? @ 0x00007fbc621d0850 (version 25.3.6.10636.altinitytest (altinity build)) 2025.07.28 11:55:09.141525 [ 17207 ] {2a20f79e-010f-4483-92d0-2c813517aaea} executeQuery: Code: 131. DB::Exception: Too large string size in function randomPrintableASCII: In scope SELECT randomPrintableASCII(nan). (TOO_LARGE_STRING_SIZE) (version 25.3.6.10636.altinitytest (altinity build)) (from [::1]:38782) (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. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x000000000a06b56b 4. /build/src/Functions/randomPrintableASCII.cpp:82: DB::(anonymous namespace)::FunctionRandomPrintableASCII::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000e5b502b 5. /build/src/Functions/IFunction.h:437: DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000a069f2a 6. /build/src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000012d9965a 7. /build/src/Functions/IFunction.cpp:351: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d93b02 8. /build/src/Functions/IFunction.cpp:420: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d95059 9. /build/src/Functions/IFunction.cpp:498: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d95c72 10. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3567: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000014034494 11. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3838: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000014019a9e 12. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3980: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000014018e31 13. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:4304: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000014042fa7 14. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5605: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000014013749 15. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000140127f9 16. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000014011fce 17. /build/src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000001406ce8a 18. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000014973b42 19. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000001497268d 20. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000014974d24 21. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001492924b 22. /build/src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88641 23. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 24. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 25. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 26. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 27. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 28. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 29. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 30. ? @ 0x00007fbc6213eac3 31. ? @ 0x00007fbc621d0850 2025.07.28 11:55:09.162345 [ 17207 ] {} 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. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x000000000a06b56b 4. /build/src/Functions/randomPrintableASCII.cpp:82: DB::(anonymous namespace)::FunctionRandomPrintableASCII::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000e5b502b 5. /build/src/Functions/IFunction.h:437: DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000a069f2a 6. /build/src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000012d9965a 7. /build/src/Functions/IFunction.cpp:351: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d93b02 8. /build/src/Functions/IFunction.cpp:420: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d95059 9. /build/src/Functions/IFunction.cpp:498: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d95c72 10. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3567: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000014034494 11. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3838: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000014019a9e 12. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3980: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000014018e31 13. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:4304: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000014042fa7 14. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5605: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000014013749 15. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000140127f9 16. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000014011fce 17. /build/src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000001406ce8a 18. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000014973b42 19. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000001497268d 20. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000014974d24 21. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001492924b 22. /build/src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88641 23. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 24. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 25. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 26. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 27. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 28. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 29. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 30. ? @ 0x00007fbc6213eac3 31. ? @ 0x00007fbc621d0850 2025.07.28 11:55:09.471875 [ 5951 ] {d3b604cb-308b-4d19-934a-e18a9edff79e} executeQuery: Code: 131. DB::Exception: Too large string size in function randomPrintableASCII: In scope SELECT randomPrintableASCII(inf). (TOO_LARGE_STRING_SIZE) (version 25.3.6.10636.altinitytest (altinity build)) (from [::1]:38800) (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. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x000000000a06b56b 4. /build/src/Functions/randomPrintableASCII.cpp:82: DB::(anonymous namespace)::FunctionRandomPrintableASCII::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000e5b502b 5. /build/src/Functions/IFunction.h:437: DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000a069f2a 6. /build/src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000012d9965a 7. /build/src/Functions/IFunction.cpp:351: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d93b02 8. /build/src/Functions/IFunction.cpp:420: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d95059 9. /build/src/Functions/IFunction.cpp:498: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d95c72 10. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3567: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000014034494 11. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3838: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000014019a9e 12. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3980: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000014018e31 13. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:4304: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000014042fa7 14. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5605: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000014013749 15. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000140127f9 16. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000014011fce 17. /build/src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000001406ce8a 18. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000014973b42 19. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000001497268d 20. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000014974d24 21. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001492924b 22. /build/src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88641 23. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 24. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 25. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 26. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 27. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 28. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 29. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 30. ? @ 0x00007fbc6213eac3 31. ? @ 0x00007fbc621d0850 2025.07.28 11:55:09.477827 [ 17207 ] {} 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. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception>&, String>(int, FormatStringHelperImpl>&>::type, std::type_identity::type>, std::basic_string_view>&, String&&) @ 0x000000001385a5eb 4. /build/src/Access/SettingsConstraints.cpp:376: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000013859b18 5. /build/src/Access/SettingsConstraints.cpp:300: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000013858faf 6. /build/src/Access/SettingsConstraints.cpp:209: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000013859223 7. /build/src/Interpreters/Context.cpp:2690: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000014436134 8. /build/src/Interpreters/Context.cpp:2729: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x000000001443662b 9. /build/src/Server/HTTPHandler.cpp:457: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000001686d165 10. /build/src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x0000000016870807 11. /build/src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x0000000016907e99 12. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 13. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 14. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 15. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 16. ? @ 0x00007fbc6213eac3 17. ? @ 0x00007fbc621d0850 (version 25.3.6.10636.altinitytest (altinity build)) 2025.07.28 11:55:09.491824 [ 5951 ] {} 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. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x000000000a06b56b 4. /build/src/Functions/randomPrintableASCII.cpp:82: DB::(anonymous namespace)::FunctionRandomPrintableASCII::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000e5b502b 5. /build/src/Functions/IFunction.h:437: DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000a069f2a 6. /build/src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000012d9965a 7. /build/src/Functions/IFunction.cpp:351: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d93b02 8. /build/src/Functions/IFunction.cpp:420: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d95059 9. /build/src/Functions/IFunction.cpp:498: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d95c72 10. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3567: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000014034494 11. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3838: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000014019a9e 12. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3980: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000014018e31 13. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:4304: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000014042fa7 14. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5605: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000014013749 15. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000140127f9 16. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000014011fce 17. /build/src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000001406ce8a 18. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000014973b42 19. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000001497268d 20. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000014974d24 21. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001492924b 22. /build/src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88641 23. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 24. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 25. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 26. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 27. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 28. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 29. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 30. ? @ 0x00007fbc6213eac3 31. ? @ 0x00007fbc621d0850 2025.07.28 11:55:09.685321 [ 7625 ] {5ea998a1-b0c0-4205-8b5f-3258ab8a14f3} StorageBuffer (test_fuwdsm6m.buffer_table1): Destination table test_fuwdsm6m.merge_tree_table1 has different type of column s (LowCardinality(String) != String). Data from destination table are converted. 2025.07.28 11:55:09.700560 [ 17207 ] {9e4c0b9e-e59e-4786-8931-a0a789bee824} executeQuery: Code: 131. DB::Exception: Too large string size in function randomPrintableASCII: In scope SELECT randomPrintableASCII(-inf). (TOO_LARGE_STRING_SIZE) (version 25.3.6.10636.altinitytest (altinity build)) (from [::1]:38830) (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. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x000000000a06b56b 4. /build/src/Functions/randomPrintableASCII.cpp:82: DB::(anonymous namespace)::FunctionRandomPrintableASCII::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000e5b502b 5. /build/src/Functions/IFunction.h:437: DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000a069f2a 6. /build/src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000012d9965a 7. /build/src/Functions/IFunction.cpp:351: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d93b02 8. /build/src/Functions/IFunction.cpp:420: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d95059 9. /build/src/Functions/IFunction.cpp:498: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d95c72 10. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3567: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000014034494 11. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3838: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000014019a9e 12. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3980: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000014018e31 13. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:4304: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000014042fa7 14. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5605: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000014013749 15. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000140127f9 16. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000014011fce 17. /build/src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000001406ce8a 18. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000014973b42 19. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000001497268d 20. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000014974d24 21. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001492924b 22. /build/src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88641 23. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 24. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 25. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 26. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 27. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 28. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 29. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 30. ? @ 0x00007fbc6213eac3 31. ? @ 0x00007fbc621d0850 2025.07.28 11:55:09.752500 [ 17207 ] {} 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. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x000000000a06b56b 4. /build/src/Functions/randomPrintableASCII.cpp:82: DB::(anonymous namespace)::FunctionRandomPrintableASCII::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000e5b502b 5. /build/src/Functions/IFunction.h:437: DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000a069f2a 6. /build/src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000012d9965a 7. /build/src/Functions/IFunction.cpp:351: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d93b02 8. /build/src/Functions/IFunction.cpp:420: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d95059 9. /build/src/Functions/IFunction.cpp:498: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d95c72 10. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3567: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000014034494 11. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3838: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000014019a9e 12. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3980: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000014018e31 13. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:4304: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000014042fa7 14. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5605: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000014013749 15. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000140127f9 16. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000014011fce 17. /build/src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000001406ce8a 18. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000014973b42 19. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000001497268d 20. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000014974d24 21. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001492924b 22. /build/src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88641 23. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 24. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 25. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 26. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 27. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 28. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 29. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 30. ? @ 0x00007fbc6213eac3 31. ? @ 0x00007fbc621d0850 2025.07.28 11:55:09.920415 [ 3963 ] {} test_13.rmt2 (7f9b740d-015c-470e-8cc6-8ba33be0dc63): auto DB::StorageReplicatedMergeTree::processQueueEntry(ReplicatedMergeTreeQueue::SelectedEntryPtr)::(anonymous class)::operator()(LogEntryPtr &) const: Code: 86. DB::HTTPException: Received error from remote server http://146b4357c08d:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Ftest%2F01165%2Ftest_13%2Frmt%2Freplicas%2F1&part=20250728_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.6.10636.altinitytest (altinity build)) '. (RECEIVED_ERROR_FROM_REMOTE_IO_SERVER), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.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 const&, int&&, String const&, unsigned long&&, String const&) @ 0x000000000feda8d9 4. /build/src/IO/HTTPCommon.cpp:104: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x000000000feda6e2 5. /build/src/IO/HTTPCommon.cpp:93: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x000000000feda537 6. /build/src/IO/ReadWriteBufferFromHTTP.cpp:277: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x000000001184a4c4 7. /build/src/IO/ReadWriteBufferFromHTTP.cpp:285: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x000000001184a615 8. /build/src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x000000001184ae59 9. /build/src/IO/ReadWriteBufferFromHTTP.cpp:472: void std::__function::__policy_invoker::__call_impl[abi:se190107]>(std::__function::__policy_storage const*) @ 0x000000001184cedd 10. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001184858b 11. /build/src/IO/ReadWriteBufferFromHTTP.cpp:465: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x000000001184bf0b 12. /build/src/IO/ReadBuffer.h:60: DB::ReadBuffer::next() @ 0x000000000a148c7b 13. /build/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) @ 0x0000000011849fb2 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]>&)>&, 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&) @ 0x0000000011841980 15. /build/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) @ 0x000000001621208e 16. /build/src/Storages/StorageReplicatedMergeTree.cpp:5228: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl[abi:se190107] const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000015f9a5fe 17. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000015ed8bfd 18. /build/src/Storages/StorageReplicatedMergeTree.cpp:2514: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x0000000015ec9aab 19. /build/src/Storages/StorageReplicatedMergeTree.cpp:2349: DB::StorageReplicatedMergeTree::executeLogEntry(DB::ReplicatedMergeTreeLogEntry&) @ 0x0000000015eba91b 20. /build/src/Storages/StorageReplicatedMergeTree.cpp:3876: bool std::__function::__policy_invoker&)>::__call_impl[abi:se190107])::$_1, bool (std::shared_ptr&)>>(std::__function::__policy_storage const*, std::shared_ptr&) @ 0x0000000015f9837e 21. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000165d6fc3 22. /build/src/Storages/StorageReplicatedMergeTree.cpp:3872: DB::StorageReplicatedMergeTree::processQueueEntry(std::shared_ptr) @ 0x0000000015efc18a 23. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001624c1b2 24. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000162f9c70 25. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x00000000162fa55a 26. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc6653 27. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000000fccc4c3 28. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc3d92 29. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fcca080 30. ? @ 0x00007fbc6213eac3 31. ? @ 0x00007fbc621d0850 (version 25.3.6.10636.altinitytest (altinity build)) 2025.07.28 11:55:09.953332 [ 17207 ] {570d2449-76a1-4615-bfec-fbce754a906e} executeQuery: Code: 131. DB::Exception: Too large string size in function randomPrintableASCII: In scope SELECT randomPrintableASCII(1e300). (TOO_LARGE_STRING_SIZE) (version 25.3.6.10636.altinitytest (altinity build)) (from [::1]:38852) (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. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x000000000a06b56b 4. /build/src/Functions/randomPrintableASCII.cpp:82: DB::(anonymous namespace)::FunctionRandomPrintableASCII::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000e5b502b 5. /build/src/Functions/IFunction.h:437: DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000a069f2a 6. /build/src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000012d9965a 7. /build/src/Functions/IFunction.cpp:351: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d93b02 8. /build/src/Functions/IFunction.cpp:420: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d95059 9. /build/src/Functions/IFunction.cpp:498: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d95c72 10. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3567: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000014034494 11. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3838: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000014019a9e 12. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3980: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000014018e31 13. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:4304: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000014042fa7 14. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5605: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000014013749 15. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000140127f9 16. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000014011fce 17. /build/src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000001406ce8a 18. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000014973b42 19. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000001497268d 20. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000014974d24 21. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001492924b 22. /build/src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88641 23. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 24. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 25. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 26. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 27. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 28. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 29. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 30. ? @ 0x00007fbc6213eac3 31. ? @ 0x00007fbc621d0850 2025.07.28 11:55:09.974696 [ 17207 ] {} 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. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x000000000a06b56b 4. /build/src/Functions/randomPrintableASCII.cpp:82: DB::(anonymous namespace)::FunctionRandomPrintableASCII::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000e5b502b 5. /build/src/Functions/IFunction.h:437: DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000a069f2a 6. /build/src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000012d9965a 7. /build/src/Functions/IFunction.cpp:351: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d93b02 8. /build/src/Functions/IFunction.cpp:420: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d95059 9. /build/src/Functions/IFunction.cpp:498: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d95c72 10. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3567: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000014034494 11. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3838: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000014019a9e 12. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3980: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000014018e31 13. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:4304: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000014042fa7 14. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5605: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000014013749 15. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000140127f9 16. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000014011fce 17. /build/src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000001406ce8a 18. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000014973b42 19. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000001497268d 20. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000014974d24 21. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001492924b 22. /build/src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88641 23. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 24. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 25. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 26. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 27. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 28. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 29. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 30. ? @ 0x00007fbc6213eac3 31. ? @ 0x00007fbc621d0850 2025.07.28 11:55:10.115182 [ 7625 ] {eeec1b3a-11c7-4480-8a2f-226f794ad718} StorageBuffer (test_fuwdsm6m.buffer_table1): Destination table test_fuwdsm6m.merge_tree_table1 has different type of column s (LowCardinality(String) != String). Data from destination table are converted. 2025.07.28 11:55:10.179207 [ 5951 ] {44a0c624-2baa-4d2d-a21b-9e9380ada181} 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.6.10636.altinitytest (altinity build)) (from [::1]:38854) (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. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x000000000a06b56b 4. /build/src/Functions/randomPrintableASCII.cpp:82: DB::(anonymous namespace)::FunctionRandomPrintableASCII::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000e5b502b 5. /build/src/Functions/IFunction.h:437: DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000a069f2a 6. /build/src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000012d9965a 7. /build/src/Functions/IFunction.cpp:351: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d93b02 8. /build/src/Functions/IFunction.cpp:420: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d95059 9. /build/src/Functions/IFunction.cpp:498: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d95c72 10. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3567: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000014034494 11. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3838: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000014019a9e 12. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3980: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000014018e31 13. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:4304: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000014042fa7 14. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5605: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000014013749 15. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000140127f9 16. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000014011fce 17. /build/src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000001406ce8a 18. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000014973b42 19. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000001497268d 20. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000014974d24 21. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001492924b 22. /build/src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88641 23. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 24. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 25. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 26. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 27. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 28. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 29. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 30. ? @ 0x00007fbc6213eac3 31. ? @ 0x00007fbc621d0850 2025.07.28 11:55:10.193757 [ 5951 ] {} 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. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x000000000a06b56b 4. /build/src/Functions/randomPrintableASCII.cpp:82: DB::(anonymous namespace)::FunctionRandomPrintableASCII::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000e5b502b 5. /build/src/Functions/IFunction.h:437: DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000a069f2a 6. /build/src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000012d9965a 7. /build/src/Functions/IFunction.cpp:351: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d93b02 8. /build/src/Functions/IFunction.cpp:420: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d95059 9. /build/src/Functions/IFunction.cpp:498: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d95c72 10. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3567: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000014034494 11. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3838: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000014019a9e 12. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3980: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000014018e31 13. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:4304: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000014042fa7 14. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5605: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000014013749 15. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000140127f9 16. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000014011fce 17. /build/src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000001406ce8a 18. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000014973b42 19. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000001497268d 20. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000014974d24 21. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001492924b 22. /build/src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88641 23. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 24. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 25. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 26. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 27. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 28. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 29. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 30. ? @ 0x00007fbc6213eac3 31. ? @ 0x00007fbc621d0850 2025.07.28 11:55:10.428629 [ 7625 ] {a610a57e-5477-4dfe-8f13-9c2fe6cea302} StorageBuffer (test_fuwdsm6m.buffer_table1): Destination table test_fuwdsm6m.merge_tree_table1 has different type of column s (LowCardinality(String) != String). Data from destination table are converted. 2025.07.28 11:55:10.452013 [ 5951 ] {11703f49-d2d5-45d2-bf2e-3b8402568bca} executeQuery: Code: 131. DB::Exception: Too large string size in function randomPrintableASCII: In scope SELECT randomPrintableASCII(-1). (TOO_LARGE_STRING_SIZE) (version 25.3.6.10636.altinitytest (altinity build)) (from [::1]:38860) (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. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x000000000a06b56b 4. /build/src/Functions/randomPrintableASCII.cpp:82: DB::(anonymous namespace)::FunctionRandomPrintableASCII::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000e5b502b 5. /build/src/Functions/IFunction.h:437: DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000a069f2a 6. /build/src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000012d9965a 7. /build/src/Functions/IFunction.cpp:351: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d93b02 8. /build/src/Functions/IFunction.cpp:420: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d95059 9. /build/src/Functions/IFunction.cpp:498: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d95c72 10. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3567: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000014034494 11. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3838: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000014019a9e 12. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3980: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000014018e31 13. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:4304: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000014042fa7 14. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5605: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000014013749 15. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000140127f9 16. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000014011fce 17. /build/src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000001406ce8a 18. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000014973b42 19. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000001497268d 20. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000014974d24 21. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001492924b 22. /build/src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88641 23. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 24. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 25. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 26. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 27. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 28. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 29. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 30. ? @ 0x00007fbc6213eac3 31. ? @ 0x00007fbc621d0850 2025.07.28 11:55:10.458419 [ 5951 ] {} 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. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x000000000a06b56b 4. /build/src/Functions/randomPrintableASCII.cpp:82: DB::(anonymous namespace)::FunctionRandomPrintableASCII::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000e5b502b 5. /build/src/Functions/IFunction.h:437: DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000a069f2a 6. /build/src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000012d9965a 7. /build/src/Functions/IFunction.cpp:351: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d93b02 8. /build/src/Functions/IFunction.cpp:420: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d95059 9. /build/src/Functions/IFunction.cpp:498: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d95c72 10. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3567: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000014034494 11. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3838: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000014019a9e 12. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3980: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000014018e31 13. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:4304: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000014042fa7 14. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5605: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000014013749 15. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000140127f9 16. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000014011fce 17. /build/src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000001406ce8a 18. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000014973b42 19. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000001497268d 20. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000014974d24 21. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001492924b 22. /build/src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88641 23. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 24. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 25. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 26. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 27. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 28. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 29. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 30. ? @ 0x00007fbc6213eac3 31. ? @ 0x00007fbc621d0850 2025.07.28 11:55:10.857882 [ 3970 ] {} test_13.rmt2 (7f9b740d-015c-470e-8cc6-8ba33be0dc63): auto DB::StorageReplicatedMergeTree::processQueueEntry(ReplicatedMergeTreeQueue::SelectedEntryPtr)::(anonymous class)::operator()(LogEntryPtr &) const: Code: 86. DB::HTTPException: Received error from remote server http://146b4357c08d:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Ftest%2F01165%2Ftest_13%2Frmt%2Freplicas%2F1&part=20250728_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.6.10636.altinitytest (altinity build)) '. (RECEIVED_ERROR_FROM_REMOTE_IO_SERVER), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.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 const&, int&&, String const&, unsigned long&&, String const&) @ 0x000000000feda8d9 4. /build/src/IO/HTTPCommon.cpp:104: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x000000000feda6e2 5. /build/src/IO/HTTPCommon.cpp:93: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x000000000feda537 6. /build/src/IO/ReadWriteBufferFromHTTP.cpp:277: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x000000001184a4c4 7. /build/src/IO/ReadWriteBufferFromHTTP.cpp:285: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x000000001184a615 8. /build/src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x000000001184ae59 9. /build/src/IO/ReadWriteBufferFromHTTP.cpp:472: void std::__function::__policy_invoker::__call_impl[abi:se190107]>(std::__function::__policy_storage const*) @ 0x000000001184cedd 10. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001184858b 11. /build/src/IO/ReadWriteBufferFromHTTP.cpp:465: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x000000001184bf0b 12. /build/src/IO/ReadBuffer.h:60: DB::ReadBuffer::next() @ 0x000000000a148c7b 13. /build/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) @ 0x0000000011849fb2 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]>&)>&, 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&) @ 0x0000000011841980 15. /build/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) @ 0x000000001621208e 16. /build/src/Storages/StorageReplicatedMergeTree.cpp:5228: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl[abi:se190107] const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000015f9a5fe 17. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000015ed8bfd 18. /build/src/Storages/StorageReplicatedMergeTree.cpp:2514: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x0000000015ec9aab 19. /build/src/Storages/StorageReplicatedMergeTree.cpp:2349: DB::StorageReplicatedMergeTree::executeLogEntry(DB::ReplicatedMergeTreeLogEntry&) @ 0x0000000015eba91b 20. /build/src/Storages/StorageReplicatedMergeTree.cpp:3876: bool std::__function::__policy_invoker&)>::__call_impl[abi:se190107])::$_1, bool (std::shared_ptr&)>>(std::__function::__policy_storage const*, std::shared_ptr&) @ 0x0000000015f9837e 21. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000165d6fc3 22. /build/src/Storages/StorageReplicatedMergeTree.cpp:3872: DB::StorageReplicatedMergeTree::processQueueEntry(std::shared_ptr) @ 0x0000000015efc18a 23. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001624c1b2 24. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000162f9c70 25. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x00000000162fa55a 26. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc6653 27. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000000fccc4c3 28. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc3d92 29. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fcca080 30. ? @ 0x00007fbc6213eac3 31. ? @ 0x00007fbc621d0850 (version 25.3.6.10636.altinitytest (altinity build)) 2025.07.28 11:55:11.619268 [ 3960 ] {} test_13.rmt2 (7f9b740d-015c-470e-8cc6-8ba33be0dc63): auto DB::StorageReplicatedMergeTree::processQueueEntry(ReplicatedMergeTreeQueue::SelectedEntryPtr)::(anonymous class)::operator()(LogEntryPtr &) const: Code: 86. DB::HTTPException: Received error from remote server http://146b4357c08d:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Ftest%2F01165%2Ftest_13%2Frmt%2Freplicas%2F1&part=20250728_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.6.10636.altinitytest (altinity build)) '. (RECEIVED_ERROR_FROM_REMOTE_IO_SERVER), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.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 const&, int&&, String const&, unsigned long&&, String const&) @ 0x000000000feda8d9 4. /build/src/IO/HTTPCommon.cpp:104: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x000000000feda6e2 5. /build/src/IO/HTTPCommon.cpp:93: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x000000000feda537 6. /build/src/IO/ReadWriteBufferFromHTTP.cpp:277: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x000000001184a4c4 7. /build/src/IO/ReadWriteBufferFromHTTP.cpp:285: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x000000001184a615 8. /build/src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x000000001184ae59 9. /build/src/IO/ReadWriteBufferFromHTTP.cpp:472: void std::__function::__policy_invoker::__call_impl[abi:se190107]>(std::__function::__policy_storage const*) @ 0x000000001184cedd 10. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001184858b 11. /build/src/IO/ReadWriteBufferFromHTTP.cpp:465: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x000000001184bf0b 12. /build/src/IO/ReadBuffer.h:60: DB::ReadBuffer::next() @ 0x000000000a148c7b 13. /build/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) @ 0x0000000011849fb2 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]>&)>&, 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&) @ 0x0000000011841980 15. /build/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) @ 0x000000001621208e 16. /build/src/Storages/StorageReplicatedMergeTree.cpp:5228: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl[abi:se190107] const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000015f9a5fe 17. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000015ed8bfd 18. /build/src/Storages/StorageReplicatedMergeTree.cpp:2514: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x0000000015ec9aab 19. /build/src/Storages/StorageReplicatedMergeTree.cpp:2349: DB::StorageReplicatedMergeTree::executeLogEntry(DB::ReplicatedMergeTreeLogEntry&) @ 0x0000000015eba91b 20. /build/src/Storages/StorageReplicatedMergeTree.cpp:3876: bool std::__function::__policy_invoker&)>::__call_impl[abi:se190107])::$_1, bool (std::shared_ptr&)>>(std::__function::__policy_storage const*, std::shared_ptr&) @ 0x0000000015f9837e 21. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000165d6fc3 22. /build/src/Storages/StorageReplicatedMergeTree.cpp:3872: DB::StorageReplicatedMergeTree::processQueueEntry(std::shared_ptr) @ 0x0000000015efc18a 23. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001624c1b2 24. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000162f9c70 25. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x00000000162fa55a 26. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc6653 27. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000000fccc4c3 28. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc3d92 29. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fcca080 30. ? @ 0x00007fbc6213eac3 31. ? @ 0x00007fbc621d0850 (version 25.3.6.10636.altinitytest (altinity build)) 2025.07.28 11:55:11.707162 [ 5951 ] {0f2987b9-776b-4aaa-a45a-71f8e8c7a42e} executeQuery: Code: 117. DB::Exception: Incorrect data: Sign = 2 (must be 1 or -1). (INCORRECT_DATA) (version 25.3.6.10636.altinitytest (altinity build)) (from [::1]:43256) (comment: 03291_collapsing_invalid_sign.sql) (query 4, line 13) (in query: INSERT INTO t_03291_collapsing_invalid_sign VALUES ), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x000000000a06b56b 4. /build/src/Processors/Merges/Algorithms/CollapsingSortedAlgorithm.cpp:222: DB::CollapsingSortedAlgorithm::merge() @ 0x0000000016cfddb3 5. /build/src/Storages/MergeTree/MergeTreeDataWriter.cpp:464: DB::MergeTreeDataWriter::mergeBlock(DB::Block&&, DB::SortDescription, std::vector> const&, DB::PODArray, 63ul, 64ul>*&, DB::MergeTreeData::MergingParams const&) @ 0x0000000016409ffb 6. /build/src/Storages/MergeTree/MergeTreeDataWriter.cpp:613: DB::MergeTreeDataWriter::writeTempPartImpl(DB::BlockWithPartition&, std::shared_ptr const&, std::shared_ptr, long, bool) @ 0x000000001640bce1 7. /build/src/Storages/MergeTree/MergeTreeDataWriter.cpp:485: DB::MergeTreeDataWriter::writeTempPart(DB::BlockWithPartition&, std::shared_ptr const&, std::shared_ptr) @ 0x000000001640a7df 8. /build/src/Storages/MergeTree/MergeTreeSink.cpp:127: DB::MergeTreeSink::consume(DB::Chunk&) @ 0x000000001666cf54 9. /build/src/Processors/Sinks/SinkToStorage.cpp:10: DB::SinkToStorage::onConsume(DB::Chunk) @ 0x0000000016cee093 10. /build/src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: void std::__function::__policy_invoker::__call_impl[abi:se190107]>(std::__function::__policy_storage const*) @ 0x0000000016c0ad89 11. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000016c0abf5 12. /build/src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: DB::ExceptionKeepingTransform::work() @ 0x0000000016c0a6fe 13. /build/src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x00000000169bd00f 14. /build/src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x00000000169b2105 15. /build/src/Processors/Executors/PipelineExecutor.cpp:170: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x00000000169b16a7 16. /build/src/Processors/Executors/PushingPipelineExecutor.cpp:131: DB::PushingPipelineExecutor::finish() @ 0x00000000169c359f 17. /build/src/Server/TCPHandler.cpp:1128: DB::TCPHandler::processInsertQuery(DB::QueryState&) @ 0x00000000168f0d2c 18. /build/src/Server/TCPHandler.cpp:673: DB::TCPHandler::runImpl() @ 0x00000000168e68bc 19. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 20. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 21. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 22. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 23. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 24. ? @ 0x00007fbc6213eac3 25. ? @ 0x00007fbc621d0850 2025.07.28 11:55:11.730635 [ 5951 ] {} TCPHandler: Code: 117. DB::Exception: Incorrect data: Sign = 2 (must be 1 or -1). (INCORRECT_DATA), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x000000000a06b56b 4. /build/src/Processors/Merges/Algorithms/CollapsingSortedAlgorithm.cpp:222: DB::CollapsingSortedAlgorithm::merge() @ 0x0000000016cfddb3 5. /build/src/Storages/MergeTree/MergeTreeDataWriter.cpp:464: DB::MergeTreeDataWriter::mergeBlock(DB::Block&&, DB::SortDescription, std::vector> const&, DB::PODArray, 63ul, 64ul>*&, DB::MergeTreeData::MergingParams const&) @ 0x0000000016409ffb 6. /build/src/Storages/MergeTree/MergeTreeDataWriter.cpp:613: DB::MergeTreeDataWriter::writeTempPartImpl(DB::BlockWithPartition&, std::shared_ptr const&, std::shared_ptr, long, bool) @ 0x000000001640bce1 7. /build/src/Storages/MergeTree/MergeTreeDataWriter.cpp:485: DB::MergeTreeDataWriter::writeTempPart(DB::BlockWithPartition&, std::shared_ptr const&, std::shared_ptr) @ 0x000000001640a7df 8. /build/src/Storages/MergeTree/MergeTreeSink.cpp:127: DB::MergeTreeSink::consume(DB::Chunk&) @ 0x000000001666cf54 9. /build/src/Processors/Sinks/SinkToStorage.cpp:10: DB::SinkToStorage::onConsume(DB::Chunk) @ 0x0000000016cee093 10. /build/src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: void std::__function::__policy_invoker::__call_impl[abi:se190107]>(std::__function::__policy_storage const*) @ 0x0000000016c0ad89 11. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000016c0abf5 12. /build/src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: DB::ExceptionKeepingTransform::work() @ 0x0000000016c0a6fe 13. /build/src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x00000000169bd00f 14. /build/src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x00000000169b2105 15. /build/src/Processors/Executors/PipelineExecutor.cpp:170: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x00000000169b16a7 16. /build/src/Processors/Executors/PushingPipelineExecutor.cpp:131: DB::PushingPipelineExecutor::finish() @ 0x00000000169c359f 17. /build/src/Server/TCPHandler.cpp:1128: DB::TCPHandler::processInsertQuery(DB::QueryState&) @ 0x00000000168f0d2c 18. /build/src/Server/TCPHandler.cpp:673: DB::TCPHandler::runImpl() @ 0x00000000168e68bc 19. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 20. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 21. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 22. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 23. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 24. ? @ 0x00007fbc6213eac3 25. ? @ 0x00007fbc621d0850 2025.07.28 11:55:11.840902 [ 4291 ] {6767e7f0-54e0-4235-9cf1-921a27dbfdaf} CollapsingSortedTransform: Incorrect data: Sign = 2 (must be 1 or -1). 2025.07.28 11:55:11.944127 [ 3967 ] {} test_13.rmt2 (7f9b740d-015c-470e-8cc6-8ba33be0dc63): auto DB::StorageReplicatedMergeTree::processQueueEntry(ReplicatedMergeTreeQueue::SelectedEntryPtr)::(anonymous class)::operator()(LogEntryPtr &) const: Code: 86. DB::HTTPException: Received error from remote server http://146b4357c08d:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Ftest%2F01165%2Ftest_13%2Frmt%2Freplicas%2F1&part=20250728_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.6.10636.altinitytest (altinity build)) '. (RECEIVED_ERROR_FROM_REMOTE_IO_SERVER), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.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 const&, int&&, String const&, unsigned long&&, String const&) @ 0x000000000feda8d9 4. /build/src/IO/HTTPCommon.cpp:104: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x000000000feda6e2 5. /build/src/IO/HTTPCommon.cpp:93: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x000000000feda537 6. /build/src/IO/ReadWriteBufferFromHTTP.cpp:277: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x000000001184a4c4 7. /build/src/IO/ReadWriteBufferFromHTTP.cpp:285: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x000000001184a615 8. /build/src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x000000001184ae59 9. /build/src/IO/ReadWriteBufferFromHTTP.cpp:472: void std::__function::__policy_invoker::__call_impl[abi:se190107]>(std::__function::__policy_storage const*) @ 0x000000001184cedd 10. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001184858b 11. /build/src/IO/ReadWriteBufferFromHTTP.cpp:465: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x000000001184bf0b 12. /build/src/IO/ReadBuffer.h:60: DB::ReadBuffer::next() @ 0x000000000a148c7b 13. /build/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) @ 0x0000000011849fb2 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]>&)>&, 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&) @ 0x0000000011841980 15. /build/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) @ 0x000000001621208e 16. /build/src/Storages/StorageReplicatedMergeTree.cpp:5228: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl[abi:se190107] const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000015f9a5fe 17. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000015ed8bfd 18. /build/src/Storages/StorageReplicatedMergeTree.cpp:2514: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x0000000015ec9aab 19. /build/src/Storages/StorageReplicatedMergeTree.cpp:2349: DB::StorageReplicatedMergeTree::executeLogEntry(DB::ReplicatedMergeTreeLogEntry&) @ 0x0000000015eba91b 20. /build/src/Storages/StorageReplicatedMergeTree.cpp:3876: bool std::__function::__policy_invoker&)>::__call_impl[abi:se190107])::$_1, bool (std::shared_ptr&)>>(std::__function::__policy_storage const*, std::shared_ptr&) @ 0x0000000015f9837e 21. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000165d6fc3 22. /build/src/Storages/StorageReplicatedMergeTree.cpp:3872: DB::StorageReplicatedMergeTree::processQueueEntry(std::shared_ptr) @ 0x0000000015efc18a 23. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001624c1b2 24. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000162f9c70 25. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x00000000162fa55a 26. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc6653 27. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000000fccc4c3 28. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc3d92 29. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fcca080 30. ? @ 0x00007fbc6213eac3 31. ? @ 0x00007fbc621d0850 (version 25.3.6.10636.altinitytest (altinity build)) 2025.07.28 11:55:12.323421 [ 3972 ] {} test_13.rmt2 (7f9b740d-015c-470e-8cc6-8ba33be0dc63): auto DB::StorageReplicatedMergeTree::processQueueEntry(ReplicatedMergeTreeQueue::SelectedEntryPtr)::(anonymous class)::operator()(LogEntryPtr &) const: Code: 86. DB::HTTPException: Received error from remote server http://146b4357c08d:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Ftest%2F01165%2Ftest_13%2Frmt%2Freplicas%2F1&part=20250728_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.6.10636.altinitytest (altinity build)) '. (RECEIVED_ERROR_FROM_REMOTE_IO_SERVER), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.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 const&, int&&, String const&, unsigned long&&, String const&) @ 0x000000000feda8d9 4. /build/src/IO/HTTPCommon.cpp:104: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x000000000feda6e2 5. /build/src/IO/HTTPCommon.cpp:93: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x000000000feda537 6. /build/src/IO/ReadWriteBufferFromHTTP.cpp:277: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x000000001184a4c4 7. /build/src/IO/ReadWriteBufferFromHTTP.cpp:285: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x000000001184a615 8. /build/src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x000000001184ae59 9. /build/src/IO/ReadWriteBufferFromHTTP.cpp:472: void std::__function::__policy_invoker::__call_impl[abi:se190107]>(std::__function::__policy_storage const*) @ 0x000000001184cedd 10. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001184858b 11. /build/src/IO/ReadWriteBufferFromHTTP.cpp:465: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x000000001184bf0b 12. /build/src/IO/ReadBuffer.h:60: DB::ReadBuffer::next() @ 0x000000000a148c7b 13. /build/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) @ 0x0000000011849fb2 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]>&)>&, 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&) @ 0x0000000011841980 15. /build/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) @ 0x000000001621208e 16. /build/src/Storages/StorageReplicatedMergeTree.cpp:5228: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl[abi:se190107] const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000015f9a5fe 17. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000015ed8bfd 18. /build/src/Storages/StorageReplicatedMergeTree.cpp:2514: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x0000000015ec9aab 19. /build/src/Storages/StorageReplicatedMergeTree.cpp:2349: DB::StorageReplicatedMergeTree::executeLogEntry(DB::ReplicatedMergeTreeLogEntry&) @ 0x0000000015eba91b 20. /build/src/Storages/StorageReplicatedMergeTree.cpp:3876: bool std::__function::__policy_invoker&)>::__call_impl[abi:se190107])::$_1, bool (std::shared_ptr&)>>(std::__function::__policy_storage const*, std::shared_ptr&) @ 0x0000000015f9837e 21. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000165d6fc3 22. /build/src/Storages/StorageReplicatedMergeTree.cpp:3872: DB::StorageReplicatedMergeTree::processQueueEntry(std::shared_ptr) @ 0x0000000015efc18a 23. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001624c1b2 24. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000162f9c70 25. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x00000000162fa55a 26. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc6653 27. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000000fccc4c3 28. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc3d92 29. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fcca080 30. ? @ 0x00007fbc6213eac3 31. ? @ 0x00007fbc621d0850 (version 25.3.6.10636.altinitytest (altinity build)) 2025.07.28 11:55:12.530845 [ 3976 ] {} test_13.rmt2 (7f9b740d-015c-470e-8cc6-8ba33be0dc63): auto DB::StorageReplicatedMergeTree::processQueueEntry(ReplicatedMergeTreeQueue::SelectedEntryPtr)::(anonymous class)::operator()(LogEntryPtr &) const: Code: 86. DB::HTTPException: Received error from remote server http://146b4357c08d:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Ftest%2F01165%2Ftest_13%2Frmt%2Freplicas%2F1&part=20250728_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.6.10636.altinitytest (altinity build)) '. (RECEIVED_ERROR_FROM_REMOTE_IO_SERVER), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.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 const&, int&&, String const&, unsigned long&&, String const&) @ 0x000000000feda8d9 4. /build/src/IO/HTTPCommon.cpp:104: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x000000000feda6e2 5. /build/src/IO/HTTPCommon.cpp:93: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x000000000feda537 6. /build/src/IO/ReadWriteBufferFromHTTP.cpp:277: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x000000001184a4c4 7. /build/src/IO/ReadWriteBufferFromHTTP.cpp:285: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x000000001184a615 8. /build/src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x000000001184ae59 9. /build/src/IO/ReadWriteBufferFromHTTP.cpp:472: void std::__function::__policy_invoker::__call_impl[abi:se190107]>(std::__function::__policy_storage const*) @ 0x000000001184cedd 10. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001184858b 11. /build/src/IO/ReadWriteBufferFromHTTP.cpp:465: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x000000001184bf0b 12. /build/src/IO/ReadBuffer.h:60: DB::ReadBuffer::next() @ 0x000000000a148c7b 13. /build/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) @ 0x0000000011849fb2 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]>&)>&, 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&) @ 0x0000000011841980 15. /build/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) @ 0x000000001621208e 16. /build/src/Storages/StorageReplicatedMergeTree.cpp:5228: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl[abi:se190107] const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000015f9a5fe 17. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000015ed8bfd 18. /build/src/Storages/StorageReplicatedMergeTree.cpp:2514: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x0000000015ec9aab 19. /build/src/Storages/StorageReplicatedMergeTree.cpp:2349: DB::StorageReplicatedMergeTree::executeLogEntry(DB::ReplicatedMergeTreeLogEntry&) @ 0x0000000015eba91b 20. /build/src/Storages/StorageReplicatedMergeTree.cpp:3876: bool std::__function::__policy_invoker&)>::__call_impl[abi:se190107])::$_1, bool (std::shared_ptr&)>>(std::__function::__policy_storage const*, std::shared_ptr&) @ 0x0000000015f9837e 21. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000165d6fc3 22. /build/src/Storages/StorageReplicatedMergeTree.cpp:3872: DB::StorageReplicatedMergeTree::processQueueEntry(std::shared_ptr) @ 0x0000000015efc18a 23. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001624c1b2 24. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000162f9c70 25. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x00000000162fa55a 26. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc6653 27. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000000fccc4c3 28. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc3d92 29. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fcca080 30. ? @ 0x00007fbc6213eac3 31. ? @ 0x00007fbc621d0850 (version 25.3.6.10636.altinitytest (altinity build)) 2025.07.28 11:55:12.927310 [ 3946 ] {7d087367-6dc0-4297-8935-42bf510a6617::all_1_6_1} CollapsingSortedTransform: Incorrect data: Sign = 0 (must be 1 or -1). 2025.07.28 11:55:12.931015 [ 3946 ] {7d087367-6dc0-4297-8935-42bf510a6617::all_1_6_1} CollapsingSortedTransform: Incorrect data: number of rows with sign = 1 (71) differs with number of rows with sign = -1 (67) by more than one (for key: ).). 2025.07.28 11:55:13.245110 [ 7395 ] {2b86efd9-1391-47b0-8ad1-4e61fcfc418e} CollapsingSortedTransform: Incorrect data: Sign = 0 (must be 1 or -1). 2025.07.28 11:55:13.267358 [ 7395 ] {2b86efd9-1391-47b0-8ad1-4e61fcfc418e} CollapsingSortedTransform: Incorrect data: number of rows with sign = 1 (71) differs with number of rows with sign = -1 (67) by more than one (for key: ).). 2025.07.28 11:55:13.398736 [ 3969 ] {} test_13.rmt2 (7f9b740d-015c-470e-8cc6-8ba33be0dc63): auto DB::StorageReplicatedMergeTree::processQueueEntry(ReplicatedMergeTreeQueue::SelectedEntryPtr)::(anonymous class)::operator()(LogEntryPtr &) const: Code: 86. DB::HTTPException: Received error from remote server http://146b4357c08d:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Ftest%2F01165%2Ftest_13%2Frmt%2Freplicas%2F1&part=20250728_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.6.10636.altinitytest (altinity build)) '. (RECEIVED_ERROR_FROM_REMOTE_IO_SERVER), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.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 const&, int&&, String const&, unsigned long&&, String const&) @ 0x000000000feda8d9 4. /build/src/IO/HTTPCommon.cpp:104: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x000000000feda6e2 5. /build/src/IO/HTTPCommon.cpp:93: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x000000000feda537 6. /build/src/IO/ReadWriteBufferFromHTTP.cpp:277: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x000000001184a4c4 7. /build/src/IO/ReadWriteBufferFromHTTP.cpp:285: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x000000001184a615 8. /build/src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x000000001184ae59 9. /build/src/IO/ReadWriteBufferFromHTTP.cpp:472: void std::__function::__policy_invoker::__call_impl[abi:se190107]>(std::__function::__policy_storage const*) @ 0x000000001184cedd 10. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001184858b 11. /build/src/IO/ReadWriteBufferFromHTTP.cpp:465: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x000000001184bf0b 12. /build/src/IO/ReadBuffer.h:60: DB::ReadBuffer::next() @ 0x000000000a148c7b 13. /build/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) @ 0x0000000011849fb2 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]>&)>&, 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&) @ 0x0000000011841980 15. /build/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) @ 0x000000001621208e 16. /build/src/Storages/StorageReplicatedMergeTree.cpp:5228: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl[abi:se190107] const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000015f9a5fe 17. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000015ed8bfd 18. /build/src/Storages/StorageReplicatedMergeTree.cpp:2514: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x0000000015ec9aab 19. /build/src/Storages/StorageReplicatedMergeTree.cpp:2349: DB::StorageReplicatedMergeTree::executeLogEntry(DB::ReplicatedMergeTreeLogEntry&) @ 0x0000000015eba91b 20. /build/src/Storages/StorageReplicatedMergeTree.cpp:3876: bool std::__function::__policy_invoker&)>::__call_impl[abi:se190107])::$_1, bool (std::shared_ptr&)>>(std::__function::__policy_storage const*, std::shared_ptr&) @ 0x0000000015f9837e 21. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000165d6fc3 22. /build/src/Storages/StorageReplicatedMergeTree.cpp:3872: DB::StorageReplicatedMergeTree::processQueueEntry(std::shared_ptr) @ 0x0000000015efc18a 23. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001624c1b2 24. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000162f9c70 25. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x00000000162fa55a 26. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc6653 27. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000000fccc4c3 28. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc3d92 29. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fcca080 30. ? @ 0x00007fbc6213eac3 31. ? @ 0x00007fbc621d0850 (version 25.3.6.10636.altinitytest (altinity build)) 2025.07.28 11:55:14.224409 [ 7625 ] {} 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. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception>&, String>(int, FormatStringHelperImpl>&>::type, std::type_identity::type>, std::basic_string_view>&, String&&) @ 0x000000001385a5eb 4. /build/src/Access/SettingsConstraints.cpp:376: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000013859b18 5. /build/src/Access/SettingsConstraints.cpp:300: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000013858faf 6. /build/src/Access/SettingsConstraints.cpp:209: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000013859223 7. /build/src/Interpreters/Context.cpp:2690: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000014436134 8. /build/src/Interpreters/Context.cpp:2729: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x000000001443662b 9. /build/src/Server/HTTPHandler.cpp:457: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000001686d165 10. /build/src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x0000000016870807 11. /build/src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x0000000016907e99 12. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 13. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 14. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 15. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 16. ? @ 0x00007fbc6213eac3 17. ? @ 0x00007fbc621d0850 (version 25.3.6.10636.altinitytest (altinity build)) 2025.07.28 11:55:14.504600 [ 3964 ] {} test_13.rmt2 (7f9b740d-015c-470e-8cc6-8ba33be0dc63): auto DB::StorageReplicatedMergeTree::processQueueEntry(ReplicatedMergeTreeQueue::SelectedEntryPtr)::(anonymous class)::operator()(LogEntryPtr &) const: Code: 86. DB::HTTPException: Received error from remote server http://146b4357c08d:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Ftest%2F01165%2Ftest_13%2Frmt%2Freplicas%2F1&part=20250728_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.6.10636.altinitytest (altinity build)) '. (RECEIVED_ERROR_FROM_REMOTE_IO_SERVER), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.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 const&, int&&, String const&, unsigned long&&, String const&) @ 0x000000000feda8d9 4. /build/src/IO/HTTPCommon.cpp:104: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x000000000feda6e2 5. /build/src/IO/HTTPCommon.cpp:93: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x000000000feda537 6. /build/src/IO/ReadWriteBufferFromHTTP.cpp:277: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x000000001184a4c4 7. /build/src/IO/ReadWriteBufferFromHTTP.cpp:285: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x000000001184a615 8. /build/src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x000000001184ae59 9. /build/src/IO/ReadWriteBufferFromHTTP.cpp:472: void std::__function::__policy_invoker::__call_impl[abi:se190107]>(std::__function::__policy_storage const*) @ 0x000000001184cedd 10. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001184858b 11. /build/src/IO/ReadWriteBufferFromHTTP.cpp:465: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x000000001184bf0b 12. /build/src/IO/ReadBuffer.h:60: DB::ReadBuffer::next() @ 0x000000000a148c7b 13. /build/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) @ 0x0000000011849fb2 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]>&)>&, 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&) @ 0x0000000011841980 15. /build/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) @ 0x000000001621208e 16. /build/src/Storages/StorageReplicatedMergeTree.cpp:5228: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl[abi:se190107] const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000015f9a5fe 17. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000015ed8bfd 18. /build/src/Storages/StorageReplicatedMergeTree.cpp:2514: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x0000000015ec9aab 19. /build/src/Storages/StorageReplicatedMergeTree.cpp:2349: DB::StorageReplicatedMergeTree::executeLogEntry(DB::ReplicatedMergeTreeLogEntry&) @ 0x0000000015eba91b 20. /build/src/Storages/StorageReplicatedMergeTree.cpp:3876: bool std::__function::__policy_invoker&)>::__call_impl[abi:se190107])::$_1, bool (std::shared_ptr&)>>(std::__function::__policy_storage const*, std::shared_ptr&) @ 0x0000000015f9837e 21. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000165d6fc3 22. /build/src/Storages/StorageReplicatedMergeTree.cpp:3872: DB::StorageReplicatedMergeTree::processQueueEntry(std::shared_ptr) @ 0x0000000015efc18a 23. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001624c1b2 24. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000162f9c70 25. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x00000000162fa55a 26. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc6653 27. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000000fccc4c3 28. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc3d92 29. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fcca080 30. ? @ 0x00007fbc6213eac3 31. ? @ 0x00007fbc621d0850 (version 25.3.6.10636.altinitytest (altinity build)) 2025.07.28 11:55:14.682808 [ 5951 ] {458dfe9b-0079-4ffa-9f05-c7dc0702ac1f::all_1_2_1} CollapsingSortedTransform: Incorrect data: Sign = 0 (must be 1 or -1). 2025.07.28 11:55:14.683964 [ 5951 ] {458dfe9b-0079-4ffa-9f05-c7dc0702ac1f::all_1_2_1} CollapsingSortedTransform: Incorrect data: Sign = 0 (must be 1 or -1). 2025.07.28 11:55:14.734992 [ 3966 ] {} test_13.rmt2 (7f9b740d-015c-470e-8cc6-8ba33be0dc63): auto DB::StorageReplicatedMergeTree::processQueueEntry(ReplicatedMergeTreeQueue::SelectedEntryPtr)::(anonymous class)::operator()(LogEntryPtr &) const: Code: 86. DB::HTTPException: Received error from remote server http://146b4357c08d:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Ftest%2F01165%2Ftest_13%2Frmt%2Freplicas%2F1&part=20250728_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.6.10636.altinitytest (altinity build)) '. (RECEIVED_ERROR_FROM_REMOTE_IO_SERVER), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.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 const&, int&&, String const&, unsigned long&&, String const&) @ 0x000000000feda8d9 4. /build/src/IO/HTTPCommon.cpp:104: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x000000000feda6e2 5. /build/src/IO/HTTPCommon.cpp:93: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x000000000feda537 6. /build/src/IO/ReadWriteBufferFromHTTP.cpp:277: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x000000001184a4c4 7. /build/src/IO/ReadWriteBufferFromHTTP.cpp:285: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x000000001184a615 8. /build/src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x000000001184ae59 9. /build/src/IO/ReadWriteBufferFromHTTP.cpp:472: void std::__function::__policy_invoker::__call_impl[abi:se190107]>(std::__function::__policy_storage const*) @ 0x000000001184cedd 10. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001184858b 11. /build/src/IO/ReadWriteBufferFromHTTP.cpp:465: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x000000001184bf0b 12. /build/src/IO/ReadBuffer.h:60: DB::ReadBuffer::next() @ 0x000000000a148c7b 13. /build/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) @ 0x0000000011849fb2 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]>&)>&, 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&) @ 0x0000000011841980 15. /build/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) @ 0x000000001621208e 16. /build/src/Storages/StorageReplicatedMergeTree.cpp:5228: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl[abi:se190107] const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000015f9a5fe 17. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000015ed8bfd 18. /build/src/Storages/StorageReplicatedMergeTree.cpp:2514: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x0000000015ec9aab 19. /build/src/Storages/StorageReplicatedMergeTree.cpp:2349: DB::StorageReplicatedMergeTree::executeLogEntry(DB::ReplicatedMergeTreeLogEntry&) @ 0x0000000015eba91b 20. /build/src/Storages/StorageReplicatedMergeTree.cpp:3876: bool std::__function::__policy_invoker&)>::__call_impl[abi:se190107])::$_1, bool (std::shared_ptr&)>>(std::__function::__policy_storage const*, std::shared_ptr&) @ 0x0000000015f9837e 21. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000165d6fc3 22. /build/src/Storages/StorageReplicatedMergeTree.cpp:3872: DB::StorageReplicatedMergeTree::processQueueEntry(std::shared_ptr) @ 0x0000000015efc18a 23. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001624c1b2 24. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000162f9c70 25. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x00000000162fa55a 26. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc6653 27. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000000fccc4c3 28. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc3d92 29. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fcca080 30. ? @ 0x00007fbc6213eac3 31. ? @ 0x00007fbc621d0850 (version 25.3.6.10636.altinitytest (altinity build)) 2025.07.28 11:55:15.284267 [ 5871 ] {f60b5376-db34-4b24-b8c5-b2ca0d34c56c} CollapsingSortedTransform: Incorrect data: Sign = 0 (must be 1 or -1). 2025.07.28 11:55:15.480645 [ 3968 ] {} test_13.rmt2 (7f9b740d-015c-470e-8cc6-8ba33be0dc63): auto DB::StorageReplicatedMergeTree::processQueueEntry(ReplicatedMergeTreeQueue::SelectedEntryPtr)::(anonymous class)::operator()(LogEntryPtr &) const: Code: 86. DB::HTTPException: Received error from remote server http://146b4357c08d:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Ftest%2F01165%2Ftest_13%2Frmt%2Freplicas%2F1&part=20250728_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.6.10636.altinitytest (altinity build)) '. (RECEIVED_ERROR_FROM_REMOTE_IO_SERVER), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.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 const&, int&&, String const&, unsigned long&&, String const&) @ 0x000000000feda8d9 4. /build/src/IO/HTTPCommon.cpp:104: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x000000000feda6e2 5. /build/src/IO/HTTPCommon.cpp:93: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x000000000feda537 6. /build/src/IO/ReadWriteBufferFromHTTP.cpp:277: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x000000001184a4c4 7. /build/src/IO/ReadWriteBufferFromHTTP.cpp:285: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x000000001184a615 8. /build/src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x000000001184ae59 9. /build/src/IO/ReadWriteBufferFromHTTP.cpp:472: void std::__function::__policy_invoker::__call_impl[abi:se190107]>(std::__function::__policy_storage const*) @ 0x000000001184cedd 10. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001184858b 11. /build/src/IO/ReadWriteBufferFromHTTP.cpp:465: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x000000001184bf0b 12. /build/src/IO/ReadBuffer.h:60: DB::ReadBuffer::next() @ 0x000000000a148c7b 13. /build/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) @ 0x0000000011849fb2 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]>&)>&, 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&) @ 0x0000000011841980 15. /build/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) @ 0x000000001621208e 16. /build/src/Storages/StorageReplicatedMergeTree.cpp:5228: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl[abi:se190107] const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000015f9a5fe 17. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000015ed8bfd 18. /build/src/Storages/StorageReplicatedMergeTree.cpp:2514: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x0000000015ec9aab 19. /build/src/Storages/StorageReplicatedMergeTree.cpp:2349: DB::StorageReplicatedMergeTree::executeLogEntry(DB::ReplicatedMergeTreeLogEntry&) @ 0x0000000015eba91b 20. /build/src/Storages/StorageReplicatedMergeTree.cpp:3876: bool std::__function::__policy_invoker&)>::__call_impl[abi:se190107])::$_1, bool (std::shared_ptr&)>>(std::__function::__policy_storage const*, std::shared_ptr&) @ 0x0000000015f9837e 21. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000165d6fc3 22. /build/src/Storages/StorageReplicatedMergeTree.cpp:3872: DB::StorageReplicatedMergeTree::processQueueEntry(std::shared_ptr) @ 0x0000000015efc18a 23. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001624c1b2 24. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000162f9c70 25. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x00000000162fa55a 26. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc6653 27. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000000fccc4c3 28. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc3d92 29. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fcca080 30. ? @ 0x00007fbc6213eac3 31. ? @ 0x00007fbc621d0850 (version 25.3.6.10636.altinitytest (altinity build)) 2025.07.28 11:55:15.773163 [ 3962 ] {} test_13.rmt2 (7f9b740d-015c-470e-8cc6-8ba33be0dc63): auto DB::StorageReplicatedMergeTree::processQueueEntry(ReplicatedMergeTreeQueue::SelectedEntryPtr)::(anonymous class)::operator()(LogEntryPtr &) const: Code: 86. DB::HTTPException: Received error from remote server http://146b4357c08d:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Ftest%2F01165%2Ftest_13%2Frmt%2Freplicas%2F1&part=20250728_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.6.10636.altinitytest (altinity build)) '. (RECEIVED_ERROR_FROM_REMOTE_IO_SERVER), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.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 const&, int&&, String const&, unsigned long&&, String const&) @ 0x000000000feda8d9 4. /build/src/IO/HTTPCommon.cpp:104: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x000000000feda6e2 5. /build/src/IO/HTTPCommon.cpp:93: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x000000000feda537 6. /build/src/IO/ReadWriteBufferFromHTTP.cpp:277: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x000000001184a4c4 7. /build/src/IO/ReadWriteBufferFromHTTP.cpp:285: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x000000001184a615 8. /build/src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x000000001184ae59 9. /build/src/IO/ReadWriteBufferFromHTTP.cpp:472: void std::__function::__policy_invoker::__call_impl[abi:se190107]>(std::__function::__policy_storage const*) @ 0x000000001184cedd 10. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001184858b 11. /build/src/IO/ReadWriteBufferFromHTTP.cpp:465: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x000000001184bf0b 12. /build/src/IO/ReadBuffer.h:60: DB::ReadBuffer::next() @ 0x000000000a148c7b 13. /build/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) @ 0x0000000011849fb2 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]>&)>&, 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&) @ 0x0000000011841980 15. /build/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) @ 0x000000001621208e 16. /build/src/Storages/StorageReplicatedMergeTree.cpp:5228: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl[abi:se190107] const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000015f9a5fe 17. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000015ed8bfd 18. /build/src/Storages/StorageReplicatedMergeTree.cpp:2514: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x0000000015ec9aab 19. /build/src/Storages/StorageReplicatedMergeTree.cpp:2349: DB::StorageReplicatedMergeTree::executeLogEntry(DB::ReplicatedMergeTreeLogEntry&) @ 0x0000000015eba91b 20. /build/src/Storages/StorageReplicatedMergeTree.cpp:3876: bool std::__function::__policy_invoker&)>::__call_impl[abi:se190107])::$_1, bool (std::shared_ptr&)>>(std::__function::__policy_storage const*, std::shared_ptr&) @ 0x0000000015f9837e 21. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000165d6fc3 22. /build/src/Storages/StorageReplicatedMergeTree.cpp:3872: DB::StorageReplicatedMergeTree::processQueueEntry(std::shared_ptr) @ 0x0000000015efc18a 23. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001624c1b2 24. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000162f9c70 25. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x00000000162fa55a 26. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc6653 27. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000000fccc4c3 28. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc3d92 29. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fcca080 30. ? @ 0x00007fbc6213eac3 31. ? @ 0x00007fbc621d0850 (version 25.3.6.10636.altinitytest (altinity build)) 2025.07.28 11:55:16.272428 [ 3977 ] {} test_13.rmt2 (7f9b740d-015c-470e-8cc6-8ba33be0dc63): auto DB::StorageReplicatedMergeTree::processQueueEntry(ReplicatedMergeTreeQueue::SelectedEntryPtr)::(anonymous class)::operator()(LogEntryPtr &) const: Code: 86. DB::HTTPException: Received error from remote server http://146b4357c08d:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Ftest%2F01165%2Ftest_13%2Frmt%2Freplicas%2F1&part=20250728_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.6.10636.altinitytest (altinity build)) '. (RECEIVED_ERROR_FROM_REMOTE_IO_SERVER), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.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 const&, int&&, String const&, unsigned long&&, String const&) @ 0x000000000feda8d9 4. /build/src/IO/HTTPCommon.cpp:104: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x000000000feda6e2 5. /build/src/IO/HTTPCommon.cpp:93: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x000000000feda537 6. /build/src/IO/ReadWriteBufferFromHTTP.cpp:277: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x000000001184a4c4 7. /build/src/IO/ReadWriteBufferFromHTTP.cpp:285: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x000000001184a615 8. /build/src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x000000001184ae59 9. /build/src/IO/ReadWriteBufferFromHTTP.cpp:472: void std::__function::__policy_invoker::__call_impl[abi:se190107]>(std::__function::__policy_storage const*) @ 0x000000001184cedd 10. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001184858b 11. /build/src/IO/ReadWriteBufferFromHTTP.cpp:465: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x000000001184bf0b 12. /build/src/IO/ReadBuffer.h:60: DB::ReadBuffer::next() @ 0x000000000a148c7b 13. /build/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) @ 0x0000000011849fb2 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]>&)>&, 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&) @ 0x0000000011841980 15. /build/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) @ 0x000000001621208e 16. /build/src/Storages/StorageReplicatedMergeTree.cpp:5228: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl[abi:se190107] const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000015f9a5fe 17. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000015ed8bfd 18. /build/src/Storages/StorageReplicatedMergeTree.cpp:2514: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x0000000015ec9aab 19. /build/src/Storages/StorageReplicatedMergeTree.cpp:2349: DB::StorageReplicatedMergeTree::executeLogEntry(DB::ReplicatedMergeTreeLogEntry&) @ 0x0000000015eba91b 20. /build/src/Storages/StorageReplicatedMergeTree.cpp:3876: bool std::__function::__policy_invoker&)>::__call_impl[abi:se190107])::$_1, bool (std::shared_ptr&)>>(std::__function::__policy_storage const*, std::shared_ptr&) @ 0x0000000015f9837e 21. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000165d6fc3 22. /build/src/Storages/StorageReplicatedMergeTree.cpp:3872: DB::StorageReplicatedMergeTree::processQueueEntry(std::shared_ptr) @ 0x0000000015efc18a 23. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001624c1b2 24. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000162f9c70 25. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x00000000162fa55a 26. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc6653 27. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000000fccc4c3 28. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc3d92 29. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fcca080 30. ? @ 0x00007fbc6213eac3 31. ? @ 0x00007fbc621d0850 (version 25.3.6.10636.altinitytest (altinity build)) 2025.07.28 11:55:17.231837 [ 3963 ] {} test_13.rmt2 (7f9b740d-015c-470e-8cc6-8ba33be0dc63): auto DB::StorageReplicatedMergeTree::processQueueEntry(ReplicatedMergeTreeQueue::SelectedEntryPtr)::(anonymous class)::operator()(LogEntryPtr &) const: Code: 86. DB::HTTPException: Received error from remote server http://146b4357c08d:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Ftest%2F01165%2Ftest_13%2Frmt%2Freplicas%2F1&part=20250728_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.6.10636.altinitytest (altinity build)) '. (RECEIVED_ERROR_FROM_REMOTE_IO_SERVER), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.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 const&, int&&, String const&, unsigned long&&, String const&) @ 0x000000000feda8d9 4. /build/src/IO/HTTPCommon.cpp:104: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x000000000feda6e2 5. /build/src/IO/HTTPCommon.cpp:93: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x000000000feda537 6. /build/src/IO/ReadWriteBufferFromHTTP.cpp:277: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x000000001184a4c4 7. /build/src/IO/ReadWriteBufferFromHTTP.cpp:285: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x000000001184a615 8. /build/src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x000000001184ae59 9. /build/src/IO/ReadWriteBufferFromHTTP.cpp:472: void std::__function::__policy_invoker::__call_impl[abi:se190107]>(std::__function::__policy_storage const*) @ 0x000000001184cedd 10. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001184858b 11. /build/src/IO/ReadWriteBufferFromHTTP.cpp:465: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x000000001184bf0b 12. /build/src/IO/ReadBuffer.h:60: DB::ReadBuffer::next() @ 0x000000000a148c7b 13. /build/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) @ 0x0000000011849fb2 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]>&)>&, 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&) @ 0x0000000011841980 15. /build/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) @ 0x000000001621208e 16. /build/src/Storages/StorageReplicatedMergeTree.cpp:5228: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl[abi:se190107] const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000015f9a5fe 17. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000015ed8bfd 18. /build/src/Storages/StorageReplicatedMergeTree.cpp:2514: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x0000000015ec9aab 19. /build/src/Storages/StorageReplicatedMergeTree.cpp:2349: DB::StorageReplicatedMergeTree::executeLogEntry(DB::ReplicatedMergeTreeLogEntry&) @ 0x0000000015eba91b 20. /build/src/Storages/StorageReplicatedMergeTree.cpp:3876: bool std::__function::__policy_invoker&)>::__call_impl[abi:se190107])::$_1, bool (std::shared_ptr&)>>(std::__function::__policy_storage const*, std::shared_ptr&) @ 0x0000000015f9837e 21. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000165d6fc3 22. /build/src/Storages/StorageReplicatedMergeTree.cpp:3872: DB::StorageReplicatedMergeTree::processQueueEntry(std::shared_ptr) @ 0x0000000015efc18a 23. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001624c1b2 24. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000162f9c70 25. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x00000000162fa55a 26. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc6653 27. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000000fccc4c3 28. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc3d92 29. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fcca080 30. ? @ 0x00007fbc6213eac3 31. ? @ 0x00007fbc621d0850 (version 25.3.6.10636.altinitytest (altinity build)) 2025.07.28 11:55:18.342338 [ 3972 ] {} test_13.rmt2 (7f9b740d-015c-470e-8cc6-8ba33be0dc63): auto DB::StorageReplicatedMergeTree::processQueueEntry(ReplicatedMergeTreeQueue::SelectedEntryPtr)::(anonymous class)::operator()(LogEntryPtr &) const: Code: 86. DB::HTTPException: Received error from remote server http://146b4357c08d:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Ftest%2F01165%2Ftest_13%2Frmt%2Freplicas%2F1&part=20250728_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.6.10636.altinitytest (altinity build)) '. (RECEIVED_ERROR_FROM_REMOTE_IO_SERVER), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.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 const&, int&&, String const&, unsigned long&&, String const&) @ 0x000000000feda8d9 4. /build/src/IO/HTTPCommon.cpp:104: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x000000000feda6e2 5. /build/src/IO/HTTPCommon.cpp:93: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x000000000feda537 6. /build/src/IO/ReadWriteBufferFromHTTP.cpp:277: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x000000001184a4c4 7. /build/src/IO/ReadWriteBufferFromHTTP.cpp:285: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x000000001184a615 8. /build/src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x000000001184ae59 9. /build/src/IO/ReadWriteBufferFromHTTP.cpp:472: void std::__function::__policy_invoker::__call_impl[abi:se190107]>(std::__function::__policy_storage const*) @ 0x000000001184cedd 10. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001184858b 11. /build/src/IO/ReadWriteBufferFromHTTP.cpp:465: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x000000001184bf0b 12. /build/src/IO/ReadBuffer.h:60: DB::ReadBuffer::next() @ 0x000000000a148c7b 13. /build/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) @ 0x0000000011849fb2 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]>&)>&, 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&) @ 0x0000000011841980 15. /build/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) @ 0x000000001621208e 16. /build/src/Storages/StorageReplicatedMergeTree.cpp:5228: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl[abi:se190107] const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000015f9a5fe 17. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000015ed8bfd 18. /build/src/Storages/StorageReplicatedMergeTree.cpp:2514: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x0000000015ec9aab 19. /build/src/Storages/StorageReplicatedMergeTree.cpp:2349: DB::StorageReplicatedMergeTree::executeLogEntry(DB::ReplicatedMergeTreeLogEntry&) @ 0x0000000015eba91b 20. /build/src/Storages/StorageReplicatedMergeTree.cpp:3876: bool std::__function::__policy_invoker&)>::__call_impl[abi:se190107])::$_1, bool (std::shared_ptr&)>>(std::__function::__policy_storage const*, std::shared_ptr&) @ 0x0000000015f9837e 21. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000165d6fc3 22. /build/src/Storages/StorageReplicatedMergeTree.cpp:3872: DB::StorageReplicatedMergeTree::processQueueEntry(std::shared_ptr) @ 0x0000000015efc18a 23. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001624c1b2 24. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000162f9c70 25. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x00000000162fa55a 26. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc6653 27. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000000fccc4c3 28. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc3d92 29. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fcca080 30. ? @ 0x00007fbc6213eac3 31. ? @ 0x00007fbc621d0850 (version 25.3.6.10636.altinitytest (altinity build)) 2025.07.28 11:55:19.234056 [ 3976 ] {} test_13.rmt2 (7f9b740d-015c-470e-8cc6-8ba33be0dc63): auto DB::StorageReplicatedMergeTree::processQueueEntry(ReplicatedMergeTreeQueue::SelectedEntryPtr)::(anonymous class)::operator()(LogEntryPtr &) const: Code: 86. DB::HTTPException: Received error from remote server http://146b4357c08d:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Ftest%2F01165%2Ftest_13%2Frmt%2Freplicas%2F1&part=20250728_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.6.10636.altinitytest (altinity build)) '. (RECEIVED_ERROR_FROM_REMOTE_IO_SERVER), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.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 const&, int&&, String const&, unsigned long&&, String const&) @ 0x000000000feda8d9 4. /build/src/IO/HTTPCommon.cpp:104: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x000000000feda6e2 5. /build/src/IO/HTTPCommon.cpp:93: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x000000000feda537 6. /build/src/IO/ReadWriteBufferFromHTTP.cpp:277: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x000000001184a4c4 7. /build/src/IO/ReadWriteBufferFromHTTP.cpp:285: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x000000001184a615 8. /build/src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x000000001184ae59 9. /build/src/IO/ReadWriteBufferFromHTTP.cpp:472: void std::__function::__policy_invoker::__call_impl[abi:se190107]>(std::__function::__policy_storage const*) @ 0x000000001184cedd 10. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001184858b 11. /build/src/IO/ReadWriteBufferFromHTTP.cpp:465: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x000000001184bf0b 12. /build/src/IO/ReadBuffer.h:60: DB::ReadBuffer::next() @ 0x000000000a148c7b 13. /build/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) @ 0x0000000011849fb2 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]>&)>&, 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&) @ 0x0000000011841980 15. /build/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) @ 0x000000001621208e 16. /build/src/Storages/StorageReplicatedMergeTree.cpp:5228: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl[abi:se190107] const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000015f9a5fe 17. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000015ed8bfd 18. /build/src/Storages/StorageReplicatedMergeTree.cpp:2514: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x0000000015ec9aab 19. /build/src/Storages/StorageReplicatedMergeTree.cpp:2349: DB::StorageReplicatedMergeTree::executeLogEntry(DB::ReplicatedMergeTreeLogEntry&) @ 0x0000000015eba91b 20. /build/src/Storages/StorageReplicatedMergeTree.cpp:3876: bool std::__function::__policy_invoker&)>::__call_impl[abi:se190107])::$_1, bool (std::shared_ptr&)>>(std::__function::__policy_storage const*, std::shared_ptr&) @ 0x0000000015f9837e 21. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000165d6fc3 22. /build/src/Storages/StorageReplicatedMergeTree.cpp:3872: DB::StorageReplicatedMergeTree::processQueueEntry(std::shared_ptr) @ 0x0000000015efc18a 23. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001624c1b2 24. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000162f9c70 25. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x00000000162fa55a 26. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc6653 27. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000000fccc4c3 28. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc3d92 29. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fcca080 30. ? @ 0x00007fbc6213eac3 31. ? @ 0x00007fbc621d0850 (version 25.3.6.10636.altinitytest (altinity build)) 2025.07.28 11:55:19.803646 [ 3965 ] {} test_13.rmt2 (7f9b740d-015c-470e-8cc6-8ba33be0dc63): auto DB::StorageReplicatedMergeTree::processQueueEntry(ReplicatedMergeTreeQueue::SelectedEntryPtr)::(anonymous class)::operator()(LogEntryPtr &) const: Code: 86. DB::HTTPException: Received error from remote server http://146b4357c08d:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Ftest%2F01165%2Ftest_13%2Frmt%2Freplicas%2F1&part=20250728_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.6.10636.altinitytest (altinity build)) '. (RECEIVED_ERROR_FROM_REMOTE_IO_SERVER), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.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 const&, int&&, String const&, unsigned long&&, String const&) @ 0x000000000feda8d9 4. /build/src/IO/HTTPCommon.cpp:104: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x000000000feda6e2 5. /build/src/IO/HTTPCommon.cpp:93: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x000000000feda537 6. /build/src/IO/ReadWriteBufferFromHTTP.cpp:277: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x000000001184a4c4 7. /build/src/IO/ReadWriteBufferFromHTTP.cpp:285: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x000000001184a615 8. /build/src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x000000001184ae59 9. /build/src/IO/ReadWriteBufferFromHTTP.cpp:472: void std::__function::__policy_invoker::__call_impl[abi:se190107]>(std::__function::__policy_storage const*) @ 0x000000001184cedd 10. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001184858b 11. /build/src/IO/ReadWriteBufferFromHTTP.cpp:465: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x000000001184bf0b 12. /build/src/IO/ReadBuffer.h:60: DB::ReadBuffer::next() @ 0x000000000a148c7b 13. /build/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) @ 0x0000000011849fb2 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]>&)>&, 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&) @ 0x0000000011841980 15. /build/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) @ 0x000000001621208e 16. /build/src/Storages/StorageReplicatedMergeTree.cpp:5228: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl[abi:se190107] const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000015f9a5fe 17. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000015ed8bfd 18. /build/src/Storages/StorageReplicatedMergeTree.cpp:2514: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x0000000015ec9aab 19. /build/src/Storages/StorageReplicatedMergeTree.cpp:2349: DB::StorageReplicatedMergeTree::executeLogEntry(DB::ReplicatedMergeTreeLogEntry&) @ 0x0000000015eba91b 20. /build/src/Storages/StorageReplicatedMergeTree.cpp:3876: bool std::__function::__policy_invoker&)>::__call_impl[abi:se190107])::$_1, bool (std::shared_ptr&)>>(std::__function::__policy_storage const*, std::shared_ptr&) @ 0x0000000015f9837e 21. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000165d6fc3 22. /build/src/Storages/StorageReplicatedMergeTree.cpp:3872: DB::StorageReplicatedMergeTree::processQueueEntry(std::shared_ptr) @ 0x0000000015efc18a 23. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001624c1b2 24. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000162f9c70 25. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x00000000162fa55a 26. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc6653 27. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000000fccc4c3 28. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc3d92 29. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fcca080 30. ? @ 0x00007fbc6213eac3 31. ? @ 0x00007fbc621d0850 (version 25.3.6.10636.altinitytest (altinity build)) 2025.07.28 11:55:20.268548 [ 3960 ] {} test_13.rmt2 (7f9b740d-015c-470e-8cc6-8ba33be0dc63): auto DB::StorageReplicatedMergeTree::processQueueEntry(ReplicatedMergeTreeQueue::SelectedEntryPtr)::(anonymous class)::operator()(LogEntryPtr &) const: Code: 86. DB::HTTPException: Received error from remote server http://146b4357c08d:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Ftest%2F01165%2Ftest_13%2Frmt%2Freplicas%2F1&part=20250728_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.6.10636.altinitytest (altinity build)) '. (RECEIVED_ERROR_FROM_REMOTE_IO_SERVER), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.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 const&, int&&, String const&, unsigned long&&, String const&) @ 0x000000000feda8d9 4. /build/src/IO/HTTPCommon.cpp:104: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x000000000feda6e2 5. /build/src/IO/HTTPCommon.cpp:93: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x000000000feda537 6. /build/src/IO/ReadWriteBufferFromHTTP.cpp:277: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x000000001184a4c4 7. /build/src/IO/ReadWriteBufferFromHTTP.cpp:285: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x000000001184a615 8. /build/src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x000000001184ae59 9. /build/src/IO/ReadWriteBufferFromHTTP.cpp:472: void std::__function::__policy_invoker::__call_impl[abi:se190107]>(std::__function::__policy_storage const*) @ 0x000000001184cedd 10. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001184858b 11. /build/src/IO/ReadWriteBufferFromHTTP.cpp:465: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x000000001184bf0b 12. /build/src/IO/ReadBuffer.h:60: DB::ReadBuffer::next() @ 0x000000000a148c7b 13. /build/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) @ 0x0000000011849fb2 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]>&)>&, 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&) @ 0x0000000011841980 15. /build/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) @ 0x000000001621208e 16. /build/src/Storages/StorageReplicatedMergeTree.cpp:5228: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl[abi:se190107] const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000015f9a5fe 17. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000015ed8bfd 18. /build/src/Storages/StorageReplicatedMergeTree.cpp:2514: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x0000000015ec9aab 19. /build/src/Storages/StorageReplicatedMergeTree.cpp:2349: DB::StorageReplicatedMergeTree::executeLogEntry(DB::ReplicatedMergeTreeLogEntry&) @ 0x0000000015eba91b 20. /build/src/Storages/StorageReplicatedMergeTree.cpp:3876: bool std::__function::__policy_invoker&)>::__call_impl[abi:se190107])::$_1, bool (std::shared_ptr&)>>(std::__function::__policy_storage const*, std::shared_ptr&) @ 0x0000000015f9837e 21. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000165d6fc3 22. /build/src/Storages/StorageReplicatedMergeTree.cpp:3872: DB::StorageReplicatedMergeTree::processQueueEntry(std::shared_ptr) @ 0x0000000015efc18a 23. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001624c1b2 24. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000162f9c70 25. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x00000000162fa55a 26. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc6653 27. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000000fccc4c3 28. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc3d92 29. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fcca080 30. ? @ 0x00007fbc6213eac3 31. ? @ 0x00007fbc621d0850 (version 25.3.6.10636.altinitytest (altinity build)) 2025.07.28 11:55:20.433246 [ 3964 ] {} test_13.rmt2 (7f9b740d-015c-470e-8cc6-8ba33be0dc63): auto DB::StorageReplicatedMergeTree::processQueueEntry(ReplicatedMergeTreeQueue::SelectedEntryPtr)::(anonymous class)::operator()(LogEntryPtr &) const: Code: 86. DB::HTTPException: Received error from remote server http://146b4357c08d:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Ftest%2F01165%2Ftest_13%2Frmt%2Freplicas%2F1&part=20250728_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.6.10636.altinitytest (altinity build)) '. (RECEIVED_ERROR_FROM_REMOTE_IO_SERVER), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.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 const&, int&&, String const&, unsigned long&&, String const&) @ 0x000000000feda8d9 4. /build/src/IO/HTTPCommon.cpp:104: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x000000000feda6e2 5. /build/src/IO/HTTPCommon.cpp:93: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x000000000feda537 6. /build/src/IO/ReadWriteBufferFromHTTP.cpp:277: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x000000001184a4c4 7. /build/src/IO/ReadWriteBufferFromHTTP.cpp:285: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x000000001184a615 8. /build/src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x000000001184ae59 9. /build/src/IO/ReadWriteBufferFromHTTP.cpp:472: void std::__function::__policy_invoker::__call_impl[abi:se190107]>(std::__function::__policy_storage const*) @ 0x000000001184cedd 10. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001184858b 11. /build/src/IO/ReadWriteBufferFromHTTP.cpp:465: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x000000001184bf0b 12. /build/src/IO/ReadBuffer.h:60: DB::ReadBuffer::next() @ 0x000000000a148c7b 13. /build/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) @ 0x0000000011849fb2 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]>&)>&, 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&) @ 0x0000000011841980 15. /build/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) @ 0x000000001621208e 16. /build/src/Storages/StorageReplicatedMergeTree.cpp:5228: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl[abi:se190107] const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000015f9a5fe 17. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000015ed8bfd 18. /build/src/Storages/StorageReplicatedMergeTree.cpp:2514: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x0000000015ec9aab 19. /build/src/Storages/StorageReplicatedMergeTree.cpp:2349: DB::StorageReplicatedMergeTree::executeLogEntry(DB::ReplicatedMergeTreeLogEntry&) @ 0x0000000015eba91b 20. /build/src/Storages/StorageReplicatedMergeTree.cpp:3876: bool std::__function::__policy_invoker&)>::__call_impl[abi:se190107])::$_1, bool (std::shared_ptr&)>>(std::__function::__policy_storage const*, std::shared_ptr&) @ 0x0000000015f9837e 21. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000165d6fc3 22. /build/src/Storages/StorageReplicatedMergeTree.cpp:3872: DB::StorageReplicatedMergeTree::processQueueEntry(std::shared_ptr) @ 0x0000000015efc18a 23. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001624c1b2 24. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000162f9c70 25. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x00000000162fa55a 26. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc6653 27. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000000fccc4c3 28. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc3d92 29. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fcca080 30. ? @ 0x00007fbc6213eac3 31. ? @ 0x00007fbc621d0850 (version 25.3.6.10636.altinitytest (altinity build)) 2025.07.28 11:55:20.699959 [ 17287 ] {} 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. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception>&, String>(int, FormatStringHelperImpl>&>::type, std::type_identity::type>, std::basic_string_view>&, String&&) @ 0x000000001385a5eb 4. /build/src/Access/SettingsConstraints.cpp:376: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000013859b18 5. /build/src/Access/SettingsConstraints.cpp:300: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000013858faf 6. /build/src/Access/SettingsConstraints.cpp:209: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000013859223 7. /build/src/Interpreters/Context.cpp:2690: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000014436134 8. /build/src/Interpreters/Context.cpp:2729: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x000000001443662b 9. /build/src/Server/HTTPHandler.cpp:457: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000001686d165 10. /build/src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x0000000016870807 11. /build/src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x0000000016907e99 12. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 13. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 14. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 15. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 16. ? @ 0x00007fbc6213eac3 17. ? @ 0x00007fbc621d0850 (version 25.3.6.10636.altinitytest (altinity build)) 2025.07.28 11:55:21.470411 [ 3966 ] {} test_13.rmt2 (7f9b740d-015c-470e-8cc6-8ba33be0dc63): auto DB::StorageReplicatedMergeTree::processQueueEntry(ReplicatedMergeTreeQueue::SelectedEntryPtr)::(anonymous class)::operator()(LogEntryPtr &) const: Code: 86. DB::HTTPException: Received error from remote server http://146b4357c08d:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Ftest%2F01165%2Ftest_13%2Frmt%2Freplicas%2F1&part=20250728_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.6.10636.altinitytest (altinity build)) '. (RECEIVED_ERROR_FROM_REMOTE_IO_SERVER), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.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 const&, int&&, String const&, unsigned long&&, String const&) @ 0x000000000feda8d9 4. /build/src/IO/HTTPCommon.cpp:104: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x000000000feda6e2 5. /build/src/IO/HTTPCommon.cpp:93: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x000000000feda537 6. /build/src/IO/ReadWriteBufferFromHTTP.cpp:277: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x000000001184a4c4 7. /build/src/IO/ReadWriteBufferFromHTTP.cpp:285: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x000000001184a615 8. /build/src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x000000001184ae59 9. /build/src/IO/ReadWriteBufferFromHTTP.cpp:472: void std::__function::__policy_invoker::__call_impl[abi:se190107]>(std::__function::__policy_storage const*) @ 0x000000001184cedd 10. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001184858b 11. /build/src/IO/ReadWriteBufferFromHTTP.cpp:465: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x000000001184bf0b 12. /build/src/IO/ReadBuffer.h:60: DB::ReadBuffer::next() @ 0x000000000a148c7b 13. /build/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) @ 0x0000000011849fb2 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]>&)>&, 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&) @ 0x0000000011841980 15. /build/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) @ 0x000000001621208e 16. /build/src/Storages/StorageReplicatedMergeTree.cpp:5228: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl[abi:se190107] const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000015f9a5fe 17. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000015ed8bfd 18. /build/src/Storages/StorageReplicatedMergeTree.cpp:2514: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x0000000015ec9aab 19. /build/src/Storages/StorageReplicatedMergeTree.cpp:2349: DB::StorageReplicatedMergeTree::executeLogEntry(DB::ReplicatedMergeTreeLogEntry&) @ 0x0000000015eba91b 20. /build/src/Storages/StorageReplicatedMergeTree.cpp:3876: bool std::__function::__policy_invoker&)>::__call_impl[abi:se190107])::$_1, bool (std::shared_ptr&)>>(std::__function::__policy_storage const*, std::shared_ptr&) @ 0x0000000015f9837e 21. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000165d6fc3 22. /build/src/Storages/StorageReplicatedMergeTree.cpp:3872: DB::StorageReplicatedMergeTree::processQueueEntry(std::shared_ptr) @ 0x0000000015efc18a 23. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001624c1b2 24. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000162f9c70 25. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x00000000162fa55a 26. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc6653 27. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000000fccc4c3 28. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc3d92 29. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fcca080 30. ? @ 0x00007fbc6213eac3 31. ? @ 0x00007fbc621d0850 (version 25.3.6.10636.altinitytest (altinity build)) 2025.07.28 11:55:21.864964 [ 3962 ] {} test_13.rmt2 (7f9b740d-015c-470e-8cc6-8ba33be0dc63): auto DB::StorageReplicatedMergeTree::processQueueEntry(ReplicatedMergeTreeQueue::SelectedEntryPtr)::(anonymous class)::operator()(LogEntryPtr &) const: Code: 86. DB::HTTPException: Received error from remote server http://146b4357c08d:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Ftest%2F01165%2Ftest_13%2Frmt%2Freplicas%2F1&part=20250728_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.6.10636.altinitytest (altinity build)) '. (RECEIVED_ERROR_FROM_REMOTE_IO_SERVER), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.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 const&, int&&, String const&, unsigned long&&, String const&) @ 0x000000000feda8d9 4. /build/src/IO/HTTPCommon.cpp:104: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x000000000feda6e2 5. /build/src/IO/HTTPCommon.cpp:93: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x000000000feda537 6. /build/src/IO/ReadWriteBufferFromHTTP.cpp:277: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x000000001184a4c4 7. /build/src/IO/ReadWriteBufferFromHTTP.cpp:285: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x000000001184a615 8. /build/src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x000000001184ae59 9. /build/src/IO/ReadWriteBufferFromHTTP.cpp:472: void std::__function::__policy_invoker::__call_impl[abi:se190107]>(std::__function::__policy_storage const*) @ 0x000000001184cedd 10. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001184858b 11. /build/src/IO/ReadWriteBufferFromHTTP.cpp:465: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x000000001184bf0b 12. /build/src/IO/ReadBuffer.h:60: DB::ReadBuffer::next() @ 0x000000000a148c7b 13. /build/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) @ 0x0000000011849fb2 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]>&)>&, 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&) @ 0x0000000011841980 15. /build/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) @ 0x000000001621208e 16. /build/src/Storages/StorageReplicatedMergeTree.cpp:5228: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl[abi:se190107] const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000015f9a5fe 17. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000015ed8bfd 18. /build/src/Storages/StorageReplicatedMergeTree.cpp:2514: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x0000000015ec9aab 19. /build/src/Storages/StorageReplicatedMergeTree.cpp:2349: DB::StorageReplicatedMergeTree::executeLogEntry(DB::ReplicatedMergeTreeLogEntry&) @ 0x0000000015eba91b 20. /build/src/Storages/StorageReplicatedMergeTree.cpp:3876: bool std::__function::__policy_invoker&)>::__call_impl[abi:se190107])::$_1, bool (std::shared_ptr&)>>(std::__function::__policy_storage const*, std::shared_ptr&) @ 0x0000000015f9837e 21. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000165d6fc3 22. /build/src/Storages/StorageReplicatedMergeTree.cpp:3872: DB::StorageReplicatedMergeTree::processQueueEntry(std::shared_ptr) @ 0x0000000015efc18a 23. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001624c1b2 24. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000162f9c70 25. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x00000000162fa55a 26. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc6653 27. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000000fccc4c3 28. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc3d92 29. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fcca080 30. ? @ 0x00007fbc6213eac3 31. ? @ 0x00007fbc621d0850 (version 25.3.6.10636.altinitytest (altinity build)) 2025.07.28 11:55:22.379175 [ 3972 ] {} test_13.rmt2 (7f9b740d-015c-470e-8cc6-8ba33be0dc63): auto DB::StorageReplicatedMergeTree::processQueueEntry(ReplicatedMergeTreeQueue::SelectedEntryPtr)::(anonymous class)::operator()(LogEntryPtr &) const: Code: 86. DB::HTTPException: Received error from remote server http://146b4357c08d:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Ftest%2F01165%2Ftest_13%2Frmt%2Freplicas%2F1&part=20250728_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.6.10636.altinitytest (altinity build)) '. (RECEIVED_ERROR_FROM_REMOTE_IO_SERVER), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.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 const&, int&&, String const&, unsigned long&&, String const&) @ 0x000000000feda8d9 4. /build/src/IO/HTTPCommon.cpp:104: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x000000000feda6e2 5. /build/src/IO/HTTPCommon.cpp:93: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x000000000feda537 6. /build/src/IO/ReadWriteBufferFromHTTP.cpp:277: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x000000001184a4c4 7. /build/src/IO/ReadWriteBufferFromHTTP.cpp:285: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x000000001184a615 8. /build/src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x000000001184ae59 9. /build/src/IO/ReadWriteBufferFromHTTP.cpp:472: void std::__function::__policy_invoker::__call_impl[abi:se190107]>(std::__function::__policy_storage const*) @ 0x000000001184cedd 10. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001184858b 11. /build/src/IO/ReadWriteBufferFromHTTP.cpp:465: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x000000001184bf0b 12. /build/src/IO/ReadBuffer.h:60: DB::ReadBuffer::next() @ 0x000000000a148c7b 13. /build/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) @ 0x0000000011849fb2 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]>&)>&, 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&) @ 0x0000000011841980 15. /build/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) @ 0x000000001621208e 16. /build/src/Storages/StorageReplicatedMergeTree.cpp:5228: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl[abi:se190107] const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000015f9a5fe 17. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000015ed8bfd 18. /build/src/Storages/StorageReplicatedMergeTree.cpp:2514: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x0000000015ec9aab 19. /build/src/Storages/StorageReplicatedMergeTree.cpp:2349: DB::StorageReplicatedMergeTree::executeLogEntry(DB::ReplicatedMergeTreeLogEntry&) @ 0x0000000015eba91b 20. /build/src/Storages/StorageReplicatedMergeTree.cpp:3876: bool std::__function::__policy_invoker&)>::__call_impl[abi:se190107])::$_1, bool (std::shared_ptr&)>>(std::__function::__policy_storage const*, std::shared_ptr&) @ 0x0000000015f9837e 21. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000165d6fc3 22. /build/src/Storages/StorageReplicatedMergeTree.cpp:3872: DB::StorageReplicatedMergeTree::processQueueEntry(std::shared_ptr) @ 0x0000000015efc18a 23. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001624c1b2 24. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000162f9c70 25. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x00000000162fa55a 26. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc6653 27. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000000fccc4c3 28. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc3d92 29. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fcca080 30. ? @ 0x00007fbc6213eac3 31. ? @ 0x00007fbc621d0850 (version 25.3.6.10636.altinitytest (altinity build)) 2025.07.28 11:55:23.006012 [ 3968 ] {} test_13.rmt2 (7f9b740d-015c-470e-8cc6-8ba33be0dc63): auto DB::StorageReplicatedMergeTree::processQueueEntry(ReplicatedMergeTreeQueue::SelectedEntryPtr)::(anonymous class)::operator()(LogEntryPtr &) const: Code: 86. DB::HTTPException: Received error from remote server http://146b4357c08d:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Ftest%2F01165%2Ftest_13%2Frmt%2Freplicas%2F1&part=20250728_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.6.10636.altinitytest (altinity build)) '. (RECEIVED_ERROR_FROM_REMOTE_IO_SERVER), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.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 const&, int&&, String const&, unsigned long&&, String const&) @ 0x000000000feda8d9 4. /build/src/IO/HTTPCommon.cpp:104: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x000000000feda6e2 5. /build/src/IO/HTTPCommon.cpp:93: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x000000000feda537 6. /build/src/IO/ReadWriteBufferFromHTTP.cpp:277: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x000000001184a4c4 7. /build/src/IO/ReadWriteBufferFromHTTP.cpp:285: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x000000001184a615 8. /build/src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x000000001184ae59 9. /build/src/IO/ReadWriteBufferFromHTTP.cpp:472: void std::__function::__policy_invoker::__call_impl[abi:se190107]>(std::__function::__policy_storage const*) @ 0x000000001184cedd 10. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001184858b 11. /build/src/IO/ReadWriteBufferFromHTTP.cpp:465: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x000000001184bf0b 12. /build/src/IO/ReadBuffer.h:60: DB::ReadBuffer::next() @ 0x000000000a148c7b 13. /build/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) @ 0x0000000011849fb2 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]>&)>&, 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&) @ 0x0000000011841980 15. /build/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) @ 0x000000001621208e 16. /build/src/Storages/StorageReplicatedMergeTree.cpp:5228: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl[abi:se190107] const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000015f9a5fe 17. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000015ed8bfd 18. /build/src/Storages/StorageReplicatedMergeTree.cpp:2514: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x0000000015ec9aab 19. /build/src/Storages/StorageReplicatedMergeTree.cpp:2349: DB::StorageReplicatedMergeTree::executeLogEntry(DB::ReplicatedMergeTreeLogEntry&) @ 0x0000000015eba91b 20. /build/src/Storages/StorageReplicatedMergeTree.cpp:3876: bool std::__function::__policy_invoker&)>::__call_impl[abi:se190107])::$_1, bool (std::shared_ptr&)>>(std::__function::__policy_storage const*, std::shared_ptr&) @ 0x0000000015f9837e 21. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000165d6fc3 22. /build/src/Storages/StorageReplicatedMergeTree.cpp:3872: DB::StorageReplicatedMergeTree::processQueueEntry(std::shared_ptr) @ 0x0000000015efc18a 23. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001624c1b2 24. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000162f9c70 25. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x00000000162fa55a 26. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc6653 27. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000000fccc4c3 28. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc3d92 29. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fcca080 30. ? @ 0x00007fbc6213eac3 31. ? @ 0x00007fbc621d0850 (version 25.3.6.10636.altinitytest (altinity build)) 2025.07.28 11:55:23.101499 [ 17371 ] {} 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. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception>&, String>(int, FormatStringHelperImpl>&>::type, std::type_identity::type>, std::basic_string_view>&, String&&) @ 0x000000001385a5eb 4. /build/src/Access/SettingsConstraints.cpp:376: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000013859b18 5. /build/src/Access/SettingsConstraints.cpp:300: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000013858faf 6. /build/src/Access/SettingsConstraints.cpp:209: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000013859223 7. /build/src/Interpreters/Context.cpp:2690: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000014436134 8. /build/src/Interpreters/Context.cpp:2729: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x000000001443662b 9. /build/src/Server/HTTPHandler.cpp:457: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000001686d165 10. /build/src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x0000000016870807 11. /build/src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x0000000016907e99 12. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 13. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 14. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 15. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 16. ? @ 0x00007fbc6213eac3 17. ? @ 0x00007fbc621d0850 (version 25.3.6.10636.altinitytest (altinity build)) 2025.07.28 11:55:24.168077 [ 3962 ] {} test_13.rmt2 (7f9b740d-015c-470e-8cc6-8ba33be0dc63): auto DB::StorageReplicatedMergeTree::processQueueEntry(ReplicatedMergeTreeQueue::SelectedEntryPtr)::(anonymous class)::operator()(LogEntryPtr &) const: Code: 86. DB::HTTPException: Received error from remote server http://146b4357c08d:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Ftest%2F01165%2Ftest_13%2Frmt%2Freplicas%2F1&part=20250728_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.6.10636.altinitytest (altinity build)) '. (RECEIVED_ERROR_FROM_REMOTE_IO_SERVER), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.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 const&, int&&, String const&, unsigned long&&, String const&) @ 0x000000000feda8d9 4. /build/src/IO/HTTPCommon.cpp:104: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x000000000feda6e2 5. /build/src/IO/HTTPCommon.cpp:93: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x000000000feda537 6. /build/src/IO/ReadWriteBufferFromHTTP.cpp:277: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x000000001184a4c4 7. /build/src/IO/ReadWriteBufferFromHTTP.cpp:285: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x000000001184a615 8. /build/src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x000000001184ae59 9. /build/src/IO/ReadWriteBufferFromHTTP.cpp:472: void std::__function::__policy_invoker::__call_impl[abi:se190107]>(std::__function::__policy_storage const*) @ 0x000000001184cedd 10. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001184858b 11. /build/src/IO/ReadWriteBufferFromHTTP.cpp:465: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x000000001184bf0b 12. /build/src/IO/ReadBuffer.h:60: DB::ReadBuffer::next() @ 0x000000000a148c7b 13. /build/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) @ 0x0000000011849fb2 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]>&)>&, 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&) @ 0x0000000011841980 15. /build/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) @ 0x000000001621208e 16. /build/src/Storages/StorageReplicatedMergeTree.cpp:5228: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl[abi:se190107] const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000015f9a5fe 17. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000015ed8bfd 18. /build/src/Storages/StorageReplicatedMergeTree.cpp:2514: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x0000000015ec9aab 19. /build/src/Storages/StorageReplicatedMergeTree.cpp:2349: DB::StorageReplicatedMergeTree::executeLogEntry(DB::ReplicatedMergeTreeLogEntry&) @ 0x0000000015eba91b 20. /build/src/Storages/StorageReplicatedMergeTree.cpp:3876: bool std::__function::__policy_invoker&)>::__call_impl[abi:se190107])::$_1, bool (std::shared_ptr&)>>(std::__function::__policy_storage const*, std::shared_ptr&) @ 0x0000000015f9837e 21. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000165d6fc3 22. /build/src/Storages/StorageReplicatedMergeTree.cpp:3872: DB::StorageReplicatedMergeTree::processQueueEntry(std::shared_ptr) @ 0x0000000015efc18a 23. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001624c1b2 24. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000162f9c70 25. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x00000000162fa55a 26. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc6653 27. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000000fccc4c3 28. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc3d92 29. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fcca080 30. ? @ 0x00007fbc6213eac3 31. ? @ 0x00007fbc621d0850 (version 25.3.6.10636.altinitytest (altinity build)) 2025.07.28 11:55:25.136699 [ 3974 ] {} test_13.rmt2 (7f9b740d-015c-470e-8cc6-8ba33be0dc63): auto DB::StorageReplicatedMergeTree::processQueueEntry(ReplicatedMergeTreeQueue::SelectedEntryPtr)::(anonymous class)::operator()(LogEntryPtr &) const: Code: 86. DB::HTTPException: Received error from remote server http://146b4357c08d:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Ftest%2F01165%2Ftest_13%2Frmt%2Freplicas%2F1&part=20250728_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.6.10636.altinitytest (altinity build)) '. (RECEIVED_ERROR_FROM_REMOTE_IO_SERVER), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.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 const&, int&&, String const&, unsigned long&&, String const&) @ 0x000000000feda8d9 4. /build/src/IO/HTTPCommon.cpp:104: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x000000000feda6e2 5. /build/src/IO/HTTPCommon.cpp:93: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x000000000feda537 6. /build/src/IO/ReadWriteBufferFromHTTP.cpp:277: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x000000001184a4c4 7. /build/src/IO/ReadWriteBufferFromHTTP.cpp:285: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x000000001184a615 8. /build/src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x000000001184ae59 9. /build/src/IO/ReadWriteBufferFromHTTP.cpp:472: void std::__function::__policy_invoker::__call_impl[abi:se190107]>(std::__function::__policy_storage const*) @ 0x000000001184cedd 10. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001184858b 11. /build/src/IO/ReadWriteBufferFromHTTP.cpp:465: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x000000001184bf0b 12. /build/src/IO/ReadBuffer.h:60: DB::ReadBuffer::next() @ 0x000000000a148c7b 13. /build/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) @ 0x0000000011849fb2 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]>&)>&, 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&) @ 0x0000000011841980 15. /build/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) @ 0x000000001621208e 16. /build/src/Storages/StorageReplicatedMergeTree.cpp:5228: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl[abi:se190107] const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000015f9a5fe 17. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000015ed8bfd 18. /build/src/Storages/StorageReplicatedMergeTree.cpp:2514: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x0000000015ec9aab 19. /build/src/Storages/StorageReplicatedMergeTree.cpp:2349: DB::StorageReplicatedMergeTree::executeLogEntry(DB::ReplicatedMergeTreeLogEntry&) @ 0x0000000015eba91b 20. /build/src/Storages/StorageReplicatedMergeTree.cpp:3876: bool std::__function::__policy_invoker&)>::__call_impl[abi:se190107])::$_1, bool (std::shared_ptr&)>>(std::__function::__policy_storage const*, std::shared_ptr&) @ 0x0000000015f9837e 21. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000165d6fc3 22. /build/src/Storages/StorageReplicatedMergeTree.cpp:3872: DB::StorageReplicatedMergeTree::processQueueEntry(std::shared_ptr) @ 0x0000000015efc18a 23. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001624c1b2 24. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000162f9c70 25. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x00000000162fa55a 26. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc6653 27. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000000fccc4c3 28. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc3d92 29. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fcca080 30. ? @ 0x00007fbc6213eac3 31. ? @ 0x00007fbc621d0850 (version 25.3.6.10636.altinitytest (altinity build)) 2025.07.28 11:55:26.094390 [ 3976 ] {} test_13.rmt2 (7f9b740d-015c-470e-8cc6-8ba33be0dc63): auto DB::StorageReplicatedMergeTree::processQueueEntry(ReplicatedMergeTreeQueue::SelectedEntryPtr)::(anonymous class)::operator()(LogEntryPtr &) const: Code: 86. DB::HTTPException: Received error from remote server http://146b4357c08d:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Ftest%2F01165%2Ftest_13%2Frmt%2Freplicas%2F1&part=20250728_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.6.10636.altinitytest (altinity build)) '. (RECEIVED_ERROR_FROM_REMOTE_IO_SERVER), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.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 const&, int&&, String const&, unsigned long&&, String const&) @ 0x000000000feda8d9 4. /build/src/IO/HTTPCommon.cpp:104: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x000000000feda6e2 5. /build/src/IO/HTTPCommon.cpp:93: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x000000000feda537 6. /build/src/IO/ReadWriteBufferFromHTTP.cpp:277: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x000000001184a4c4 7. /build/src/IO/ReadWriteBufferFromHTTP.cpp:285: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x000000001184a615 8. /build/src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x000000001184ae59 9. /build/src/IO/ReadWriteBufferFromHTTP.cpp:472: void std::__function::__policy_invoker::__call_impl[abi:se190107]>(std::__function::__policy_storage const*) @ 0x000000001184cedd 10. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001184858b 11. /build/src/IO/ReadWriteBufferFromHTTP.cpp:465: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x000000001184bf0b 12. /build/src/IO/ReadBuffer.h:60: DB::ReadBuffer::next() @ 0x000000000a148c7b 13. /build/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) @ 0x0000000011849fb2 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]>&)>&, 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&) @ 0x0000000011841980 15. /build/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) @ 0x000000001621208e 16. /build/src/Storages/StorageReplicatedMergeTree.cpp:5228: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl[abi:se190107] const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000015f9a5fe 17. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000015ed8bfd 18. /build/src/Storages/StorageReplicatedMergeTree.cpp:2514: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x0000000015ec9aab 19. /build/src/Storages/StorageReplicatedMergeTree.cpp:2349: DB::StorageReplicatedMergeTree::executeLogEntry(DB::ReplicatedMergeTreeLogEntry&) @ 0x0000000015eba91b 20. /build/src/Storages/StorageReplicatedMergeTree.cpp:3876: bool std::__function::__policy_invoker&)>::__call_impl[abi:se190107])::$_1, bool (std::shared_ptr&)>>(std::__function::__policy_storage const*, std::shared_ptr&) @ 0x0000000015f9837e 21. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000165d6fc3 22. /build/src/Storages/StorageReplicatedMergeTree.cpp:3872: DB::StorageReplicatedMergeTree::processQueueEntry(std::shared_ptr) @ 0x0000000015efc18a 23. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001624c1b2 24. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000162f9c70 25. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x00000000162fa55a 26. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc6653 27. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000000fccc4c3 28. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc3d92 29. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fcca080 30. ? @ 0x00007fbc6213eac3 31. ? @ 0x00007fbc621d0850 (version 25.3.6.10636.altinitytest (altinity build)) 2025.07.28 11:55:27.103442 [ 3960 ] {} test_13.rmt2 (7f9b740d-015c-470e-8cc6-8ba33be0dc63): auto DB::StorageReplicatedMergeTree::processQueueEntry(ReplicatedMergeTreeQueue::SelectedEntryPtr)::(anonymous class)::operator()(LogEntryPtr &) const: Code: 86. DB::HTTPException: Received error from remote server http://146b4357c08d:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Ftest%2F01165%2Ftest_13%2Frmt%2Freplicas%2F1&part=20250728_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.6.10636.altinitytest (altinity build)) '. (RECEIVED_ERROR_FROM_REMOTE_IO_SERVER), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.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 const&, int&&, String const&, unsigned long&&, String const&) @ 0x000000000feda8d9 4. /build/src/IO/HTTPCommon.cpp:104: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x000000000feda6e2 5. /build/src/IO/HTTPCommon.cpp:93: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x000000000feda537 6. /build/src/IO/ReadWriteBufferFromHTTP.cpp:277: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x000000001184a4c4 7. /build/src/IO/ReadWriteBufferFromHTTP.cpp:285: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x000000001184a615 8. /build/src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x000000001184ae59 9. /build/src/IO/ReadWriteBufferFromHTTP.cpp:472: void std::__function::__policy_invoker::__call_impl[abi:se190107]>(std::__function::__policy_storage const*) @ 0x000000001184cedd 10. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001184858b 11. /build/src/IO/ReadWriteBufferFromHTTP.cpp:465: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x000000001184bf0b 12. /build/src/IO/ReadBuffer.h:60: DB::ReadBuffer::next() @ 0x000000000a148c7b 13. /build/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) @ 0x0000000011849fb2 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]>&)>&, 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&) @ 0x0000000011841980 15. /build/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) @ 0x000000001621208e 16. /build/src/Storages/StorageReplicatedMergeTree.cpp:5228: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl[abi:se190107] const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000015f9a5fe 17. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000015ed8bfd 18. /build/src/Storages/StorageReplicatedMergeTree.cpp:2514: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x0000000015ec9aab 19. /build/src/Storages/StorageReplicatedMergeTree.cpp:2349: DB::StorageReplicatedMergeTree::executeLogEntry(DB::ReplicatedMergeTreeLogEntry&) @ 0x0000000015eba91b 20. /build/src/Storages/StorageReplicatedMergeTree.cpp:3876: bool std::__function::__policy_invoker&)>::__call_impl[abi:se190107])::$_1, bool (std::shared_ptr&)>>(std::__function::__policy_storage const*, std::shared_ptr&) @ 0x0000000015f9837e 21. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000165d6fc3 22. /build/src/Storages/StorageReplicatedMergeTree.cpp:3872: DB::StorageReplicatedMergeTree::processQueueEntry(std::shared_ptr) @ 0x0000000015efc18a 23. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001624c1b2 24. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000162f9c70 25. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x00000000162fa55a 26. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc6653 27. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000000fccc4c3 28. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc3d92 29. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fcca080 30. ? @ 0x00007fbc6213eac3 31. ? @ 0x00007fbc621d0850 (version 25.3.6.10636.altinitytest (altinity build)) 2025.07.28 11:55:27.570667 [ 3940 ] {} MergeTreeBackgroundExecutor: Exception while executing background task {fc6f1762-9c4a-45c7-8bc3-a06ac7661037::202507_48_62_3}: 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. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, char const*&&, char const*&&) @ 0x000000000fc1a8eb 4. /build/src/Common/MemoryTracker.cpp:196: MemoryTracker::injectFault() const @ 0x000000000fc18390 5. /build/src/Storages/MergeTree/MergePlainMergeTreeTask.cpp:153: DB::MergePlainMergeTreeTask::finish() @ 0x000000001666f399 6. /build/src/Storages/MergeTree/MergePlainMergeTreeTask.cpp:72: DB::MergePlainMergeTreeTask::executeStep() @ 0x000000001666e852 7. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000162fc850 8. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x00000000162fd193 9. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc6653 10. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000000fccc4c3 11. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc3d92 12. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fcca080 13. ? @ 0x00007fbc6213eac3 14. ? @ 0x00007fbc621d0850 (version 25.3.6.10636.altinitytest (altinity build)) 2025.07.28 11:55:27.952586 [ 3965 ] {} test_13.rmt2 (7f9b740d-015c-470e-8cc6-8ba33be0dc63): auto DB::StorageReplicatedMergeTree::processQueueEntry(ReplicatedMergeTreeQueue::SelectedEntryPtr)::(anonymous class)::operator()(LogEntryPtr &) const: Code: 86. DB::HTTPException: Received error from remote server http://146b4357c08d:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Ftest%2F01165%2Ftest_13%2Frmt%2Freplicas%2F1&part=20250728_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.6.10636.altinitytest (altinity build)) '. (RECEIVED_ERROR_FROM_REMOTE_IO_SERVER), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.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 const&, int&&, String const&, unsigned long&&, String const&) @ 0x000000000feda8d9 4. /build/src/IO/HTTPCommon.cpp:104: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x000000000feda6e2 5. /build/src/IO/HTTPCommon.cpp:93: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x000000000feda537 6. /build/src/IO/ReadWriteBufferFromHTTP.cpp:277: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x000000001184a4c4 7. /build/src/IO/ReadWriteBufferFromHTTP.cpp:285: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x000000001184a615 8. /build/src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x000000001184ae59 9. /build/src/IO/ReadWriteBufferFromHTTP.cpp:472: void std::__function::__policy_invoker::__call_impl[abi:se190107]>(std::__function::__policy_storage const*) @ 0x000000001184cedd 10. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001184858b 11. /build/src/IO/ReadWriteBufferFromHTTP.cpp:465: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x000000001184bf0b 12. /build/src/IO/ReadBuffer.h:60: DB::ReadBuffer::next() @ 0x000000000a148c7b 13. /build/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) @ 0x0000000011849fb2 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]>&)>&, 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&) @ 0x0000000011841980 15. /build/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) @ 0x000000001621208e 16. /build/src/Storages/StorageReplicatedMergeTree.cpp:5228: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl[abi:se190107] const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000015f9a5fe 17. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000015ed8bfd 18. /build/src/Storages/StorageReplicatedMergeTree.cpp:2514: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x0000000015ec9aab 19. /build/src/Storages/StorageReplicatedMergeTree.cpp:2349: DB::StorageReplicatedMergeTree::executeLogEntry(DB::ReplicatedMergeTreeLogEntry&) @ 0x0000000015eba91b 20. /build/src/Storages/StorageReplicatedMergeTree.cpp:3876: bool std::__function::__policy_invoker&)>::__call_impl[abi:se190107])::$_1, bool (std::shared_ptr&)>>(std::__function::__policy_storage const*, std::shared_ptr&) @ 0x0000000015f9837e 21. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000165d6fc3 22. /build/src/Storages/StorageReplicatedMergeTree.cpp:3872: DB::StorageReplicatedMergeTree::processQueueEntry(std::shared_ptr) @ 0x0000000015efc18a 23. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001624c1b2 24. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000162f9c70 25. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x00000000162fa55a 26. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc6653 27. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000000fccc4c3 28. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc3d92 29. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fcca080 30. ? @ 0x00007fbc6213eac3 31. ? @ 0x00007fbc621d0850 (version 25.3.6.10636.altinitytest (altinity build)) 2025.07.28 11:55:29.094640 [ 3967 ] {} test_13.rmt2 (7f9b740d-015c-470e-8cc6-8ba33be0dc63): auto DB::StorageReplicatedMergeTree::processQueueEntry(ReplicatedMergeTreeQueue::SelectedEntryPtr)::(anonymous class)::operator()(LogEntryPtr &) const: Code: 86. DB::HTTPException: Received error from remote server http://146b4357c08d:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Ftest%2F01165%2Ftest_13%2Frmt%2Freplicas%2F1&part=20250728_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.6.10636.altinitytest (altinity build)) '. (RECEIVED_ERROR_FROM_REMOTE_IO_SERVER), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.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 const&, int&&, String const&, unsigned long&&, String const&) @ 0x000000000feda8d9 4. /build/src/IO/HTTPCommon.cpp:104: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x000000000feda6e2 5. /build/src/IO/HTTPCommon.cpp:93: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x000000000feda537 6. /build/src/IO/ReadWriteBufferFromHTTP.cpp:277: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x000000001184a4c4 7. /build/src/IO/ReadWriteBufferFromHTTP.cpp:285: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x000000001184a615 8. /build/src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x000000001184ae59 9. /build/src/IO/ReadWriteBufferFromHTTP.cpp:472: void std::__function::__policy_invoker::__call_impl[abi:se190107]>(std::__function::__policy_storage const*) @ 0x000000001184cedd 10. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001184858b 11. /build/src/IO/ReadWriteBufferFromHTTP.cpp:465: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x000000001184bf0b 12. /build/src/IO/ReadBuffer.h:60: DB::ReadBuffer::next() @ 0x000000000a148c7b 13. /build/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) @ 0x0000000011849fb2 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]>&)>&, 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&) @ 0x0000000011841980 15. /build/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) @ 0x000000001621208e 16. /build/src/Storages/StorageReplicatedMergeTree.cpp:5228: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl[abi:se190107] const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000015f9a5fe 17. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000015ed8bfd 18. /build/src/Storages/StorageReplicatedMergeTree.cpp:2514: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x0000000015ec9aab 19. /build/src/Storages/StorageReplicatedMergeTree.cpp:2349: DB::StorageReplicatedMergeTree::executeLogEntry(DB::ReplicatedMergeTreeLogEntry&) @ 0x0000000015eba91b 20. /build/src/Storages/StorageReplicatedMergeTree.cpp:3876: bool std::__function::__policy_invoker&)>::__call_impl[abi:se190107])::$_1, bool (std::shared_ptr&)>>(std::__function::__policy_storage const*, std::shared_ptr&) @ 0x0000000015f9837e 21. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000165d6fc3 22. /build/src/Storages/StorageReplicatedMergeTree.cpp:3872: DB::StorageReplicatedMergeTree::processQueueEntry(std::shared_ptr) @ 0x0000000015efc18a 23. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001624c1b2 24. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000162f9c70 25. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x00000000162fa55a 26. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc6653 27. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000000fccc4c3 28. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc3d92 29. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fcca080 30. ? @ 0x00007fbc6213eac3 31. ? @ 0x00007fbc621d0850 (version 25.3.6.10636.altinitytest (altinity build)) 2025.07.28 11:55:29.579304 [ 3960 ] {} test_13.rmt2 (7f9b740d-015c-470e-8cc6-8ba33be0dc63): auto DB::StorageReplicatedMergeTree::processQueueEntry(ReplicatedMergeTreeQueue::SelectedEntryPtr)::(anonymous class)::operator()(LogEntryPtr &) const: Code: 86. DB::HTTPException: Received error from remote server http://146b4357c08d:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Ftest%2F01165%2Ftest_13%2Frmt%2Freplicas%2F1&part=20250728_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.6.10636.altinitytest (altinity build)) '. (RECEIVED_ERROR_FROM_REMOTE_IO_SERVER), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.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 const&, int&&, String const&, unsigned long&&, String const&) @ 0x000000000feda8d9 4. /build/src/IO/HTTPCommon.cpp:104: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x000000000feda6e2 5. /build/src/IO/HTTPCommon.cpp:93: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x000000000feda537 6. /build/src/IO/ReadWriteBufferFromHTTP.cpp:277: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x000000001184a4c4 7. /build/src/IO/ReadWriteBufferFromHTTP.cpp:285: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x000000001184a615 8. /build/src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x000000001184ae59 9. /build/src/IO/ReadWriteBufferFromHTTP.cpp:472: void std::__function::__policy_invoker::__call_impl[abi:se190107]>(std::__function::__policy_storage const*) @ 0x000000001184cedd 10. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001184858b 11. /build/src/IO/ReadWriteBufferFromHTTP.cpp:465: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x000000001184bf0b 12. /build/src/IO/ReadBuffer.h:60: DB::ReadBuffer::next() @ 0x000000000a148c7b 13. /build/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) @ 0x0000000011849fb2 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]>&)>&, 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&) @ 0x0000000011841980 15. /build/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) @ 0x000000001621208e 16. /build/src/Storages/StorageReplicatedMergeTree.cpp:5228: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl[abi:se190107] const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000015f9a5fe 17. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000015ed8bfd 18. /build/src/Storages/StorageReplicatedMergeTree.cpp:2514: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x0000000015ec9aab 19. /build/src/Storages/StorageReplicatedMergeTree.cpp:2349: DB::StorageReplicatedMergeTree::executeLogEntry(DB::ReplicatedMergeTreeLogEntry&) @ 0x0000000015eba91b 20. /build/src/Storages/StorageReplicatedMergeTree.cpp:3876: bool std::__function::__policy_invoker&)>::__call_impl[abi:se190107])::$_1, bool (std::shared_ptr&)>>(std::__function::__policy_storage const*, std::shared_ptr&) @ 0x0000000015f9837e 21. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000165d6fc3 22. /build/src/Storages/StorageReplicatedMergeTree.cpp:3872: DB::StorageReplicatedMergeTree::processQueueEntry(std::shared_ptr) @ 0x0000000015efc18a 23. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001624c1b2 24. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000162f9c70 25. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x00000000162fa55a 26. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc6653 27. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000000fccc4c3 28. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc3d92 29. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fcca080 30. ? @ 0x00007fbc6213eac3 31. ? @ 0x00007fbc621d0850 (version 25.3.6.10636.altinitytest (altinity build)) 2025.07.28 11:55:30.526922 [ 3976 ] {} test_13.rmt2 (7f9b740d-015c-470e-8cc6-8ba33be0dc63): auto DB::StorageReplicatedMergeTree::processQueueEntry(ReplicatedMergeTreeQueue::SelectedEntryPtr)::(anonymous class)::operator()(LogEntryPtr &) const: Code: 86. DB::HTTPException: Received error from remote server http://146b4357c08d:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Ftest%2F01165%2Ftest_13%2Frmt%2Freplicas%2F1&part=20250728_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.6.10636.altinitytest (altinity build)) '. (RECEIVED_ERROR_FROM_REMOTE_IO_SERVER), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.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 const&, int&&, String const&, unsigned long&&, String const&) @ 0x000000000feda8d9 4. /build/src/IO/HTTPCommon.cpp:104: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x000000000feda6e2 5. /build/src/IO/HTTPCommon.cpp:93: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x000000000feda537 6. /build/src/IO/ReadWriteBufferFromHTTP.cpp:277: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x000000001184a4c4 7. /build/src/IO/ReadWriteBufferFromHTTP.cpp:285: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x000000001184a615 8. /build/src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x000000001184ae59 9. /build/src/IO/ReadWriteBufferFromHTTP.cpp:472: void std::__function::__policy_invoker::__call_impl[abi:se190107]>(std::__function::__policy_storage const*) @ 0x000000001184cedd 10. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001184858b 11. /build/src/IO/ReadWriteBufferFromHTTP.cpp:465: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x000000001184bf0b 12. /build/src/IO/ReadBuffer.h:60: DB::ReadBuffer::next() @ 0x000000000a148c7b 13. /build/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) @ 0x0000000011849fb2 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]>&)>&, 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&) @ 0x0000000011841980 15. /build/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) @ 0x000000001621208e 16. /build/src/Storages/StorageReplicatedMergeTree.cpp:5228: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl[abi:se190107] const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000015f9a5fe 17. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000015ed8bfd 18. /build/src/Storages/StorageReplicatedMergeTree.cpp:2514: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x0000000015ec9aab 19. /build/src/Storages/StorageReplicatedMergeTree.cpp:2349: DB::StorageReplicatedMergeTree::executeLogEntry(DB::ReplicatedMergeTreeLogEntry&) @ 0x0000000015eba91b 20. /build/src/Storages/StorageReplicatedMergeTree.cpp:3876: bool std::__function::__policy_invoker&)>::__call_impl[abi:se190107])::$_1, bool (std::shared_ptr&)>>(std::__function::__policy_storage const*, std::shared_ptr&) @ 0x0000000015f9837e 21. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000165d6fc3 22. /build/src/Storages/StorageReplicatedMergeTree.cpp:3872: DB::StorageReplicatedMergeTree::processQueueEntry(std::shared_ptr) @ 0x0000000015efc18a 23. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001624c1b2 24. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000162f9c70 25. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x00000000162fa55a 26. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc6653 27. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000000fccc4c3 28. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc3d92 29. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fcca080 30. ? @ 0x00007fbc6213eac3 31. ? @ 0x00007fbc621d0850 (version 25.3.6.10636.altinitytest (altinity build)) 2025.07.28 11:55:31.280500 [ 3977 ] {} test_13.rmt2 (7f9b740d-015c-470e-8cc6-8ba33be0dc63): auto DB::StorageReplicatedMergeTree::processQueueEntry(ReplicatedMergeTreeQueue::SelectedEntryPtr)::(anonymous class)::operator()(LogEntryPtr &) const: Code: 86. DB::HTTPException: Received error from remote server http://146b4357c08d:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Ftest%2F01165%2Ftest_13%2Frmt%2Freplicas%2F1&part=20250728_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.6.10636.altinitytest (altinity build)) '. (RECEIVED_ERROR_FROM_REMOTE_IO_SERVER), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.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 const&, int&&, String const&, unsigned long&&, String const&) @ 0x000000000feda8d9 4. /build/src/IO/HTTPCommon.cpp:104: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x000000000feda6e2 5. /build/src/IO/HTTPCommon.cpp:93: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x000000000feda537 6. /build/src/IO/ReadWriteBufferFromHTTP.cpp:277: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x000000001184a4c4 7. /build/src/IO/ReadWriteBufferFromHTTP.cpp:285: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x000000001184a615 8. /build/src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x000000001184ae59 9. /build/src/IO/ReadWriteBufferFromHTTP.cpp:472: void std::__function::__policy_invoker::__call_impl[abi:se190107]>(std::__function::__policy_storage const*) @ 0x000000001184cedd 10. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001184858b 11. /build/src/IO/ReadWriteBufferFromHTTP.cpp:465: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x000000001184bf0b 12. /build/src/IO/ReadBuffer.h:60: DB::ReadBuffer::next() @ 0x000000000a148c7b 13. /build/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) @ 0x0000000011849fb2 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]>&)>&, 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&) @ 0x0000000011841980 15. /build/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) @ 0x000000001621208e 16. /build/src/Storages/StorageReplicatedMergeTree.cpp:5228: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl[abi:se190107] const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000015f9a5fe 17. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000015ed8bfd 18. /build/src/Storages/StorageReplicatedMergeTree.cpp:2514: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x0000000015ec9aab 19. /build/src/Storages/StorageReplicatedMergeTree.cpp:2349: DB::StorageReplicatedMergeTree::executeLogEntry(DB::ReplicatedMergeTreeLogEntry&) @ 0x0000000015eba91b 20. /build/src/Storages/StorageReplicatedMergeTree.cpp:3876: bool std::__function::__policy_invoker&)>::__call_impl[abi:se190107])::$_1, bool (std::shared_ptr&)>>(std::__function::__policy_storage const*, std::shared_ptr&) @ 0x0000000015f9837e 21. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000165d6fc3 22. /build/src/Storages/StorageReplicatedMergeTree.cpp:3872: DB::StorageReplicatedMergeTree::processQueueEntry(std::shared_ptr) @ 0x0000000015efc18a 23. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001624c1b2 24. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000162f9c70 25. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x00000000162fa55a 26. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc6653 27. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000000fccc4c3 28. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc3d92 29. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fcca080 30. ? @ 0x00007fbc6213eac3 31. ? @ 0x00007fbc621d0850 (version 25.3.6.10636.altinitytest (altinity build)) 2025.07.28 11:55:31.871025 [ 3965 ] {} test_13.rmt2 (7f9b740d-015c-470e-8cc6-8ba33be0dc63): auto DB::StorageReplicatedMergeTree::processQueueEntry(ReplicatedMergeTreeQueue::SelectedEntryPtr)::(anonymous class)::operator()(LogEntryPtr &) const: Code: 86. DB::HTTPException: Received error from remote server http://146b4357c08d:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Ftest%2F01165%2Ftest_13%2Frmt%2Freplicas%2F1&part=20250728_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.6.10636.altinitytest (altinity build)) '. (RECEIVED_ERROR_FROM_REMOTE_IO_SERVER), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.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 const&, int&&, String const&, unsigned long&&, String const&) @ 0x000000000feda8d9 4. /build/src/IO/HTTPCommon.cpp:104: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x000000000feda6e2 5. /build/src/IO/HTTPCommon.cpp:93: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x000000000feda537 6. /build/src/IO/ReadWriteBufferFromHTTP.cpp:277: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x000000001184a4c4 7. /build/src/IO/ReadWriteBufferFromHTTP.cpp:285: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x000000001184a615 8. /build/src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x000000001184ae59 9. /build/src/IO/ReadWriteBufferFromHTTP.cpp:472: void std::__function::__policy_invoker::__call_impl[abi:se190107]>(std::__function::__policy_storage const*) @ 0x000000001184cedd 10. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001184858b 11. /build/src/IO/ReadWriteBufferFromHTTP.cpp:465: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x000000001184bf0b 12. /build/src/IO/ReadBuffer.h:60: DB::ReadBuffer::next() @ 0x000000000a148c7b 13. /build/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) @ 0x0000000011849fb2 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]>&)>&, 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&) @ 0x0000000011841980 15. /build/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) @ 0x000000001621208e 16. /build/src/Storages/StorageReplicatedMergeTree.cpp:5228: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl[abi:se190107] const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000015f9a5fe 17. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000015ed8bfd 18. /build/src/Storages/StorageReplicatedMergeTree.cpp:2514: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x0000000015ec9aab 19. /build/src/Storages/StorageReplicatedMergeTree.cpp:2349: DB::StorageReplicatedMergeTree::executeLogEntry(DB::ReplicatedMergeTreeLogEntry&) @ 0x0000000015eba91b 20. /build/src/Storages/StorageReplicatedMergeTree.cpp:3876: bool std::__function::__policy_invoker&)>::__call_impl[abi:se190107])::$_1, bool (std::shared_ptr&)>>(std::__function::__policy_storage const*, std::shared_ptr&) @ 0x0000000015f9837e 21. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000165d6fc3 22. /build/src/Storages/StorageReplicatedMergeTree.cpp:3872: DB::StorageReplicatedMergeTree::processQueueEntry(std::shared_ptr) @ 0x0000000015efc18a 23. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001624c1b2 24. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000162f9c70 25. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x00000000162fa55a 26. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc6653 27. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000000fccc4c3 28. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc3d92 29. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fcca080 30. ? @ 0x00007fbc6213eac3 31. ? @ 0x00007fbc621d0850 (version 25.3.6.10636.altinitytest (altinity build)) 2025.07.28 11:55:32.908843 [ 3961 ] {} test_13.rmt2 (7f9b740d-015c-470e-8cc6-8ba33be0dc63): auto DB::StorageReplicatedMergeTree::processQueueEntry(ReplicatedMergeTreeQueue::SelectedEntryPtr)::(anonymous class)::operator()(LogEntryPtr &) const: Code: 86. DB::HTTPException: Received error from remote server http://146b4357c08d:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Ftest%2F01165%2Ftest_13%2Frmt%2Freplicas%2F1&part=20250728_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.6.10636.altinitytest (altinity build)) '. (RECEIVED_ERROR_FROM_REMOTE_IO_SERVER), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.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 const&, int&&, String const&, unsigned long&&, String const&) @ 0x000000000feda8d9 4. /build/src/IO/HTTPCommon.cpp:104: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x000000000feda6e2 5. /build/src/IO/HTTPCommon.cpp:93: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x000000000feda537 6. /build/src/IO/ReadWriteBufferFromHTTP.cpp:277: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x000000001184a4c4 7. /build/src/IO/ReadWriteBufferFromHTTP.cpp:285: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x000000001184a615 8. /build/src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x000000001184ae59 9. /build/src/IO/ReadWriteBufferFromHTTP.cpp:472: void std::__function::__policy_invoker::__call_impl[abi:se190107]>(std::__function::__policy_storage const*) @ 0x000000001184cedd 10. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001184858b 11. /build/src/IO/ReadWriteBufferFromHTTP.cpp:465: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x000000001184bf0b 12. /build/src/IO/ReadBuffer.h:60: DB::ReadBuffer::next() @ 0x000000000a148c7b 13. /build/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) @ 0x0000000011849fb2 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]>&)>&, 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&) @ 0x0000000011841980 15. /build/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) @ 0x000000001621208e 16. /build/src/Storages/StorageReplicatedMergeTree.cpp:5228: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl[abi:se190107] const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000015f9a5fe 17. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000015ed8bfd 18. /build/src/Storages/StorageReplicatedMergeTree.cpp:2514: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x0000000015ec9aab 19. /build/src/Storages/StorageReplicatedMergeTree.cpp:2349: DB::StorageReplicatedMergeTree::executeLogEntry(DB::ReplicatedMergeTreeLogEntry&) @ 0x0000000015eba91b 20. /build/src/Storages/StorageReplicatedMergeTree.cpp:3876: bool std::__function::__policy_invoker&)>::__call_impl[abi:se190107])::$_1, bool (std::shared_ptr&)>>(std::__function::__policy_storage const*, std::shared_ptr&) @ 0x0000000015f9837e 21. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000165d6fc3 22. /build/src/Storages/StorageReplicatedMergeTree.cpp:3872: DB::StorageReplicatedMergeTree::processQueueEntry(std::shared_ptr) @ 0x0000000015efc18a 23. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001624c1b2 24. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000162f9c70 25. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x00000000162fa55a 26. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc6653 27. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000000fccc4c3 28. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc3d92 29. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fcca080 30. ? @ 0x00007fbc6213eac3 31. ? @ 0x00007fbc621d0850 (version 25.3.6.10636.altinitytest (altinity build)) 2025.07.28 11:55:34.062912 [ 3974 ] {} test_13.rmt2 (7f9b740d-015c-470e-8cc6-8ba33be0dc63): auto DB::StorageReplicatedMergeTree::processQueueEntry(ReplicatedMergeTreeQueue::SelectedEntryPtr)::(anonymous class)::operator()(LogEntryPtr &) const: Code: 86. DB::HTTPException: Received error from remote server http://146b4357c08d:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Ftest%2F01165%2Ftest_13%2Frmt%2Freplicas%2F1&part=20250728_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.6.10636.altinitytest (altinity build)) '. (RECEIVED_ERROR_FROM_REMOTE_IO_SERVER), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.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 const&, int&&, String const&, unsigned long&&, String const&) @ 0x000000000feda8d9 4. /build/src/IO/HTTPCommon.cpp:104: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x000000000feda6e2 5. /build/src/IO/HTTPCommon.cpp:93: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x000000000feda537 6. /build/src/IO/ReadWriteBufferFromHTTP.cpp:277: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x000000001184a4c4 7. /build/src/IO/ReadWriteBufferFromHTTP.cpp:285: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x000000001184a615 8. /build/src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x000000001184ae59 9. /build/src/IO/ReadWriteBufferFromHTTP.cpp:472: void std::__function::__policy_invoker::__call_impl[abi:se190107]>(std::__function::__policy_storage const*) @ 0x000000001184cedd 10. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001184858b 11. /build/src/IO/ReadWriteBufferFromHTTP.cpp:465: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x000000001184bf0b 12. /build/src/IO/ReadBuffer.h:60: DB::ReadBuffer::next() @ 0x000000000a148c7b 13. /build/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) @ 0x0000000011849fb2 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]>&)>&, 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&) @ 0x0000000011841980 15. /build/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) @ 0x000000001621208e 16. /build/src/Storages/StorageReplicatedMergeTree.cpp:5228: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl[abi:se190107] const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000015f9a5fe 17. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000015ed8bfd 18. /build/src/Storages/StorageReplicatedMergeTree.cpp:2514: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x0000000015ec9aab 19. /build/src/Storages/StorageReplicatedMergeTree.cpp:2349: DB::StorageReplicatedMergeTree::executeLogEntry(DB::ReplicatedMergeTreeLogEntry&) @ 0x0000000015eba91b 20. /build/src/Storages/StorageReplicatedMergeTree.cpp:3876: bool std::__function::__policy_invoker&)>::__call_impl[abi:se190107])::$_1, bool (std::shared_ptr&)>>(std::__function::__policy_storage const*, std::shared_ptr&) @ 0x0000000015f9837e 21. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000165d6fc3 22. /build/src/Storages/StorageReplicatedMergeTree.cpp:3872: DB::StorageReplicatedMergeTree::processQueueEntry(std::shared_ptr) @ 0x0000000015efc18a 23. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001624c1b2 24. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000162f9c70 25. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x00000000162fa55a 26. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc6653 27. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000000fccc4c3 28. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc3d92 29. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fcca080 30. ? @ 0x00007fbc6213eac3 31. ? @ 0x00007fbc621d0850 (version 25.3.6.10636.altinitytest (altinity build)) 2025.07.28 11:55:34.550133 [ 3283 ] {c3295af3-ddf7-4b8f-abbc-bb374c4e7817} executeQuery: Code: 53. DB::Exception: Type mismatch for column n. Column has type String, got type UInt8. (TYPE_MISMATCH) (version 25.3.6.10636.altinitytest (altinity build)) (from [::1]:36468) (comment: 01182_materialized_view_different_structure.sql) (query 19, line 26) (in query: INSERT INTO mv SELECT toString(number + 1000) FROM numbers(1000);), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, String&&, String&&) @ 0x000000001098ed2b 4. /build/src/Storages/StorageInMemoryMetadata.cpp:761: DB::StorageInMemoryMetadata::check(DB::Block const&, bool) const @ 0x0000000015dbbe16 5. /build/src/Processors/Transforms/buildPushingToViewsChain.cpp:620: 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&) @ 0x0000000016cb4c10 6. /build/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*) @ 0x000000001492df0b 7. /build/src/Interpreters/InterpreterInsertQuery.cpp:503: DB::InterpreterInsertQuery::buildPreAndSinkChains(unsigned long, unsigned long, std::shared_ptr, unsigned long, std::shared_ptr const&, DB::Block const&) @ 0x000000001492f8f2 8. /build/src/Interpreters/InterpreterInsertQuery.cpp:701: DB::InterpreterInsertQuery::buildInsertSelectPipeline(DB::ASTInsertQuery&, std::shared_ptr) @ 0x00000000149310ac 9. /build/src/Interpreters/InterpreterInsertQuery.cpp:870: DB::InterpreterInsertQuery::execute() @ 0x0000000014933e3d 10. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88dc9 11. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 12. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 13. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 14. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 15. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 16. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 17. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 18. ? @ 0x00007fbc6213eac3 19. ? @ 0x00007fbc621d0850 2025.07.28 11:55:34.556848 [ 3283 ] {} TCPHandler: Code: 53. DB::Exception: Type mismatch for column n. Column has type String, got type UInt8. (TYPE_MISMATCH), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, String&&, String&&) @ 0x000000001098ed2b 4. /build/src/Storages/StorageInMemoryMetadata.cpp:761: DB::StorageInMemoryMetadata::check(DB::Block const&, bool) const @ 0x0000000015dbbe16 5. /build/src/Processors/Transforms/buildPushingToViewsChain.cpp:620: 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&) @ 0x0000000016cb4c10 6. /build/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*) @ 0x000000001492df0b 7. /build/src/Interpreters/InterpreterInsertQuery.cpp:503: DB::InterpreterInsertQuery::buildPreAndSinkChains(unsigned long, unsigned long, std::shared_ptr, unsigned long, std::shared_ptr const&, DB::Block const&) @ 0x000000001492f8f2 8. /build/src/Interpreters/InterpreterInsertQuery.cpp:701: DB::InterpreterInsertQuery::buildInsertSelectPipeline(DB::ASTInsertQuery&, std::shared_ptr) @ 0x00000000149310ac 9. /build/src/Interpreters/InterpreterInsertQuery.cpp:870: DB::InterpreterInsertQuery::execute() @ 0x0000000014933e3d 10. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88dc9 11. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 12. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 13. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 14. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 15. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 16. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 17. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 18. ? @ 0x00007fbc6213eac3 19. ? @ 0x00007fbc621d0850 2025.07.28 11:55:34.571181 [ 3967 ] {} test_13.rmt2 (7f9b740d-015c-470e-8cc6-8ba33be0dc63): auto DB::StorageReplicatedMergeTree::processQueueEntry(ReplicatedMergeTreeQueue::SelectedEntryPtr)::(anonymous class)::operator()(LogEntryPtr &) const: Code: 86. DB::HTTPException: Received error from remote server http://146b4357c08d:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Ftest%2F01165%2Ftest_13%2Frmt%2Freplicas%2F1&part=20250728_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.6.10636.altinitytest (altinity build)) '. (RECEIVED_ERROR_FROM_REMOTE_IO_SERVER), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.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 const&, int&&, String const&, unsigned long&&, String const&) @ 0x000000000feda8d9 4. /build/src/IO/HTTPCommon.cpp:104: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x000000000feda6e2 5. /build/src/IO/HTTPCommon.cpp:93: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x000000000feda537 6. /build/src/IO/ReadWriteBufferFromHTTP.cpp:277: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x000000001184a4c4 7. /build/src/IO/ReadWriteBufferFromHTTP.cpp:285: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x000000001184a615 8. /build/src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x000000001184ae59 9. /build/src/IO/ReadWriteBufferFromHTTP.cpp:472: void std::__function::__policy_invoker::__call_impl[abi:se190107]>(std::__function::__policy_storage const*) @ 0x000000001184cedd 10. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001184858b 11. /build/src/IO/ReadWriteBufferFromHTTP.cpp:465: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x000000001184bf0b 12. /build/src/IO/ReadBuffer.h:60: DB::ReadBuffer::next() @ 0x000000000a148c7b 13. /build/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) @ 0x0000000011849fb2 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]>&)>&, 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&) @ 0x0000000011841980 15. /build/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) @ 0x000000001621208e 16. /build/src/Storages/StorageReplicatedMergeTree.cpp:5228: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl[abi:se190107] const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000015f9a5fe 17. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000015ed8bfd 18. /build/src/Storages/StorageReplicatedMergeTree.cpp:2514: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x0000000015ec9aab 19. /build/src/Storages/StorageReplicatedMergeTree.cpp:2349: DB::StorageReplicatedMergeTree::executeLogEntry(DB::ReplicatedMergeTreeLogEntry&) @ 0x0000000015eba91b 20. /build/src/Storages/StorageReplicatedMergeTree.cpp:3876: bool std::__function::__policy_invoker&)>::__call_impl[abi:se190107])::$_1, bool (std::shared_ptr&)>>(std::__function::__policy_storage const*, std::shared_ptr&) @ 0x0000000015f9837e 21. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000165d6fc3 22. /build/src/Storages/StorageReplicatedMergeTree.cpp:3872: DB::StorageReplicatedMergeTree::processQueueEntry(std::shared_ptr) @ 0x0000000015efc18a 23. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001624c1b2 24. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000162f9c70 25. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x00000000162fa55a 26. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc6653 27. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000000fccc4c3 28. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc3d92 29. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fcca080 30. ? @ 0x00007fbc6213eac3 31. ? @ 0x00007fbc621d0850 (version 25.3.6.10636.altinitytest (altinity build)) 2025.07.28 11:55:34.585643 [ 3283 ] {59e34e61-63a2-4ec6-bffb-7d3f712d582c} executeQuery: Code: 53. DB::Exception: Type mismatch for column n. Column has type String, got type UInt8. (TYPE_MISMATCH) (version 25.3.6.10636.altinitytest (altinity build)) (from [::1]:36468) (comment: 01182_materialized_view_different_structure.sql) (query 20, line 27) (in query: INSERT INTO mv SELECT arrayJoin(['42', 'test']);), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, String&&, String&&) @ 0x000000001098ed2b 4. /build/src/Storages/StorageInMemoryMetadata.cpp:761: DB::StorageInMemoryMetadata::check(DB::Block const&, bool) const @ 0x0000000015dbbe16 5. /build/src/Processors/Transforms/buildPushingToViewsChain.cpp:620: 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&) @ 0x0000000016cb4c10 6. /build/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*) @ 0x000000001492df0b 7. /build/src/Interpreters/InterpreterInsertQuery.cpp:503: DB::InterpreterInsertQuery::buildPreAndSinkChains(unsigned long, unsigned long, std::shared_ptr, unsigned long, std::shared_ptr const&, DB::Block const&) @ 0x000000001492f8f2 8. /build/src/Interpreters/InterpreterInsertQuery.cpp:701: DB::InterpreterInsertQuery::buildInsertSelectPipeline(DB::ASTInsertQuery&, std::shared_ptr) @ 0x00000000149310ac 9. /build/src/Interpreters/InterpreterInsertQuery.cpp:870: DB::InterpreterInsertQuery::execute() @ 0x0000000014933e3d 10. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88dc9 11. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 12. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 13. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 14. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 15. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 16. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 17. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 18. ? @ 0x00007fbc6213eac3 19. ? @ 0x00007fbc621d0850 2025.07.28 11:55:34.588451 [ 3283 ] {} TCPHandler: Code: 53. DB::Exception: Type mismatch for column n. Column has type String, got type UInt8. (TYPE_MISMATCH), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, String&&, String&&) @ 0x000000001098ed2b 4. /build/src/Storages/StorageInMemoryMetadata.cpp:761: DB::StorageInMemoryMetadata::check(DB::Block const&, bool) const @ 0x0000000015dbbe16 5. /build/src/Processors/Transforms/buildPushingToViewsChain.cpp:620: 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&) @ 0x0000000016cb4c10 6. /build/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*) @ 0x000000001492df0b 7. /build/src/Interpreters/InterpreterInsertQuery.cpp:503: DB::InterpreterInsertQuery::buildPreAndSinkChains(unsigned long, unsigned long, std::shared_ptr, unsigned long, std::shared_ptr const&, DB::Block const&) @ 0x000000001492f8f2 8. /build/src/Interpreters/InterpreterInsertQuery.cpp:701: DB::InterpreterInsertQuery::buildInsertSelectPipeline(DB::ASTInsertQuery&, std::shared_ptr) @ 0x00000000149310ac 9. /build/src/Interpreters/InterpreterInsertQuery.cpp:870: DB::InterpreterInsertQuery::execute() @ 0x0000000014933e3d 10. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88dc9 11. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 12. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 13. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 14. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 15. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 16. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 17. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 18. ? @ 0x00007fbc6213eac3 19. ? @ 0x00007fbc621d0850 2025.07.28 11:55:35.166616 [ 3283 ] {e1ead676-71ee-4b9e-98d2-f933ba633344} executeQuery: Code: 70. DB::Exception: Conversion from AggregateFunction(max, String) to AggregateFunction(max, Int128) is not supported: while converting source column `max(__table1.n)` to destination column `max(__table1.n)`. (CANNOT_CONVERT_TYPE) (version 25.3.6.10636.altinitytest (altinity build)) (from [::1]:36468) (comment: 01182_materialized_view_different_structure.sql) (query 24, line 32) (in query: SELECT count(), sum(toInt64(n)), max(n), min(n) FROM dist;), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000a06a8eb 4. /build/src/Functions/FunctionsConversion.h:3856: DB::detail::FunctionCast::createAggregateFunctionWrapper(std::shared_ptr const&, DB::DataTypeAggregateFunction const*) const @ 0x0000000012df0fc4 5. /build/src/Functions/FunctionsConversion.h:6108: DB::detail::FunctionCast::prepareImpl(std::shared_ptr const&, std::shared_ptr const&, bool) const @ 0x0000000012dee3bf 6. /build/src/Functions/FunctionsConversion.h:5819: DB::detail::FunctionCast::prepareRemoveNullable(std::shared_ptr const&, std::shared_ptr const&, bool) const @ 0x0000000012ddd83b 7. /build/src/Functions/FunctionsConversion.h:5746: DB::detail::FunctionCast::prepareUnpackDictionaries(std::shared_ptr const&, std::shared_ptr const&) const @ 0x0000000012ddc5c9 8. /build/src/Functions/FunctionsConversion.h:3444: DB::detail::FunctionCast::prepare(std::vector> const&) const @ 0x0000000012ddbeb0 9. /build/src/Interpreters/ActionsDAG.cpp:403: DB::ActionsDAG::addFunctionImpl(std::shared_ptr const&, std::vector>, std::vector>, String, std::shared_ptr, bool) @ 0x0000000013f9c709 10. /build/src/Interpreters/ActionsDAG.cpp:362: DB::ActionsDAG::addFunction(std::shared_ptr const&, std::vector>, String) @ 0x0000000013f9d19b 11. /build/src/Interpreters/ActionsDAG.cpp:1637: DB::ActionsDAG::makeConvertingActions(std::vector> const&, std::vector> const&, DB::ActionsDAG::MatchColumnsMode, bool, bool, std::unordered_map, std::equal_to, std::allocator>>*) @ 0x0000000013faa20e 12. /build/src/Processors/QueryPlan/ConvertingActions.cpp:20: DB::addConvertingActions(DB::QueryPlan&, DB::Block const&, bool) @ 0x0000000016db890d 13. /build/src/Processors/QueryPlan/DistributedCreateLocalPlan.cpp:57: DB::createLocalPlan(std::shared_ptr const&, DB::Block const&, std::shared_ptr, DB::QueryProcessingStage::Enum, unsigned long, unsigned long, bool) @ 0x0000000016db8772 14. /build/src/Interpreters/ClusterProxy/SelectStreamFactory.cpp:169: DB::ClusterProxy::SelectStreamFactory::createForShardImpl(DB::Cluster::ShardInfo const&, std::shared_ptr const&, std::shared_ptr const&, DB::StorageID const&, std::shared_ptr const&, std::shared_ptr, std::vector>, std::allocator>>>&, std::vector>&, unsigned int, bool, std::function (unsigned long)>, bool)::$_0::operator()() const @ 0x00000000158bb391 15. /build/src/Interpreters/ClusterProxy/SelectStreamFactory.cpp:244: DB::ClusterProxy::SelectStreamFactory::createForShardImpl(DB::Cluster::ShardInfo const&, std::shared_ptr const&, std::shared_ptr const&, DB::StorageID const&, std::shared_ptr const&, std::shared_ptr, std::vector>, std::allocator>>>&, std::vector>&, unsigned int, bool, std::function (unsigned long)>, bool) @ 0x00000000158b9d24 16. /build/src/Interpreters/ClusterProxy/SelectStreamFactory.cpp:321: DB::ClusterProxy::SelectStreamFactory::createForShard(DB::Cluster::ShardInfo const&, std::shared_ptr const&, DB::StorageID const&, std::shared_ptr const&, std::shared_ptr, std::vector>, std::allocator>>>&, std::vector>&, unsigned int, bool, std::function (unsigned long)>) @ 0x00000000158bb638 17. /build/src/Interpreters/ClusterProxy/executeQuery.cpp:369: DB::ClusterProxy::executeQuery(DB::QueryPlan&, DB::Block const&, DB::QueryProcessingStage::Enum, DB::StorageID const&, std::shared_ptr const&, DB::ClusterProxy::SelectStreamFactory&, std::shared_ptr, std::shared_ptr, DB::SelectQueryInfo const&, std::shared_ptr const&, String const&, DB::DistributedSettings const&, std::function (unsigned long)>, bool) @ 0x00000000158ab761 18. /build/src/Storages/StorageDistributed.cpp:912: DB::StorageDistributed::read(DB::QueryPlan&, std::vector> const&, std::shared_ptr const&, DB::SelectQueryInfo&, std::shared_ptr, DB::QueryProcessingStage::Enum, unsigned long, unsigned long) @ 0x0000000015d63ebb 19. /build/src/Planner/PlannerJoinTree.cpp:946: DB::(anonymous namespace)::buildQueryPlanForTableExpression(std::shared_ptr, std::shared_ptr const&, DB::SelectQueryInfo const&, DB::SelectQueryOptions const&, std::shared_ptr&, bool, bool) @ 0x00000000149970ee 20. /build/src/Planner/PlannerJoinTree.cpp:2252: DB::buildJoinTreeQueryPlan(std::shared_ptr const&, DB::SelectQueryInfo const&, DB::SelectQueryOptions&, std::unordered_set, std::equal_to, std::allocator> const&, std::shared_ptr&) @ 0x000000001498e109 21. /build/src/Planner/Planner.cpp:1553: DB::Planner::buildPlanForQueryNode() @ 0x0000000014979dae 22. /build/src/Planner/Planner.cpp:1308: DB::Planner::buildQueryPlanIfNeeded() @ 0x000000001497685c 23. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:255: DB::InterpreterSelectQueryAnalyzer::getQueryPlan() @ 0x000000001497476d 24. /build/src/Interpreters/executeQuery.cpp:1405: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88806 25. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 26. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 27. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 28. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 29. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 30. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 31. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 2025.07.28 11:55:35.169952 [ 3283 ] {} TCPHandler: Code: 70. DB::Exception: Conversion from AggregateFunction(max, String) to AggregateFunction(max, Int128) is not supported: while converting source column `max(__table1.n)` to destination column `max(__table1.n)`. (CANNOT_CONVERT_TYPE), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000a06a8eb 4. /build/src/Functions/FunctionsConversion.h:3856: DB::detail::FunctionCast::createAggregateFunctionWrapper(std::shared_ptr const&, DB::DataTypeAggregateFunction const*) const @ 0x0000000012df0fc4 5. /build/src/Functions/FunctionsConversion.h:6108: DB::detail::FunctionCast::prepareImpl(std::shared_ptr const&, std::shared_ptr const&, bool) const @ 0x0000000012dee3bf 6. /build/src/Functions/FunctionsConversion.h:5819: DB::detail::FunctionCast::prepareRemoveNullable(std::shared_ptr const&, std::shared_ptr const&, bool) const @ 0x0000000012ddd83b 7. /build/src/Functions/FunctionsConversion.h:5746: DB::detail::FunctionCast::prepareUnpackDictionaries(std::shared_ptr const&, std::shared_ptr const&) const @ 0x0000000012ddc5c9 8. /build/src/Functions/FunctionsConversion.h:3444: DB::detail::FunctionCast::prepare(std::vector> const&) const @ 0x0000000012ddbeb0 9. /build/src/Interpreters/ActionsDAG.cpp:403: DB::ActionsDAG::addFunctionImpl(std::shared_ptr const&, std::vector>, std::vector>, String, std::shared_ptr, bool) @ 0x0000000013f9c709 10. /build/src/Interpreters/ActionsDAG.cpp:362: DB::ActionsDAG::addFunction(std::shared_ptr const&, std::vector>, String) @ 0x0000000013f9d19b 11. /build/src/Interpreters/ActionsDAG.cpp:1637: DB::ActionsDAG::makeConvertingActions(std::vector> const&, std::vector> const&, DB::ActionsDAG::MatchColumnsMode, bool, bool, std::unordered_map, std::equal_to, std::allocator>>*) @ 0x0000000013faa20e 12. /build/src/Processors/QueryPlan/ConvertingActions.cpp:20: DB::addConvertingActions(DB::QueryPlan&, DB::Block const&, bool) @ 0x0000000016db890d 13. /build/src/Processors/QueryPlan/DistributedCreateLocalPlan.cpp:57: DB::createLocalPlan(std::shared_ptr const&, DB::Block const&, std::shared_ptr, DB::QueryProcessingStage::Enum, unsigned long, unsigned long, bool) @ 0x0000000016db8772 14. /build/src/Interpreters/ClusterProxy/SelectStreamFactory.cpp:169: DB::ClusterProxy::SelectStreamFactory::createForShardImpl(DB::Cluster::ShardInfo const&, std::shared_ptr const&, std::shared_ptr const&, DB::StorageID const&, std::shared_ptr const&, std::shared_ptr, std::vector>, std::allocator>>>&, std::vector>&, unsigned int, bool, std::function (unsigned long)>, bool)::$_0::operator()() const @ 0x00000000158bb391 15. /build/src/Interpreters/ClusterProxy/SelectStreamFactory.cpp:244: DB::ClusterProxy::SelectStreamFactory::createForShardImpl(DB::Cluster::ShardInfo const&, std::shared_ptr const&, std::shared_ptr const&, DB::StorageID const&, std::shared_ptr const&, std::shared_ptr, std::vector>, std::allocator>>>&, std::vector>&, unsigned int, bool, std::function (unsigned long)>, bool) @ 0x00000000158b9d24 16. /build/src/Interpreters/ClusterProxy/SelectStreamFactory.cpp:321: DB::ClusterProxy::SelectStreamFactory::createForShard(DB::Cluster::ShardInfo const&, std::shared_ptr const&, DB::StorageID const&, std::shared_ptr const&, std::shared_ptr, std::vector>, std::allocator>>>&, std::vector>&, unsigned int, bool, std::function (unsigned long)>) @ 0x00000000158bb638 17. /build/src/Interpreters/ClusterProxy/executeQuery.cpp:369: DB::ClusterProxy::executeQuery(DB::QueryPlan&, DB::Block const&, DB::QueryProcessingStage::Enum, DB::StorageID const&, std::shared_ptr const&, DB::ClusterProxy::SelectStreamFactory&, std::shared_ptr, std::shared_ptr, DB::SelectQueryInfo const&, std::shared_ptr const&, String const&, DB::DistributedSettings const&, std::function (unsigned long)>, bool) @ 0x00000000158ab761 18. /build/src/Storages/StorageDistributed.cpp:912: DB::StorageDistributed::read(DB::QueryPlan&, std::vector> const&, std::shared_ptr const&, DB::SelectQueryInfo&, std::shared_ptr, DB::QueryProcessingStage::Enum, unsigned long, unsigned long) @ 0x0000000015d63ebb 19. /build/src/Planner/PlannerJoinTree.cpp:946: DB::(anonymous namespace)::buildQueryPlanForTableExpression(std::shared_ptr, std::shared_ptr const&, DB::SelectQueryInfo const&, DB::SelectQueryOptions const&, std::shared_ptr&, bool, bool) @ 0x00000000149970ee 20. /build/src/Planner/PlannerJoinTree.cpp:2252: DB::buildJoinTreeQueryPlan(std::shared_ptr const&, DB::SelectQueryInfo const&, DB::SelectQueryOptions&, std::unordered_set, std::equal_to, std::allocator> const&, std::shared_ptr&) @ 0x000000001498e109 21. /build/src/Planner/Planner.cpp:1553: DB::Planner::buildPlanForQueryNode() @ 0x0000000014979dae 22. /build/src/Planner/Planner.cpp:1308: DB::Planner::buildQueryPlanIfNeeded() @ 0x000000001497685c 23. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:255: DB::InterpreterSelectQueryAnalyzer::getQueryPlan() @ 0x000000001497476d 24. /build/src/Interpreters/executeQuery.cpp:1405: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88806 25. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 26. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 27. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 28. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 29. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 30. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 31. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 2025.07.28 11:55:35.430062 [ 3970 ] {} test_13.rmt2 (7f9b740d-015c-470e-8cc6-8ba33be0dc63): auto DB::StorageReplicatedMergeTree::processQueueEntry(ReplicatedMergeTreeQueue::SelectedEntryPtr)::(anonymous class)::operator()(LogEntryPtr &) const: Code: 86. DB::HTTPException: Received error from remote server http://146b4357c08d:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Ftest%2F01165%2Ftest_13%2Frmt%2Freplicas%2F1&part=20250728_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.6.10636.altinitytest (altinity build)) '. (RECEIVED_ERROR_FROM_REMOTE_IO_SERVER), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.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 const&, int&&, String const&, unsigned long&&, String const&) @ 0x000000000feda8d9 4. /build/src/IO/HTTPCommon.cpp:104: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x000000000feda6e2 5. /build/src/IO/HTTPCommon.cpp:93: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x000000000feda537 6. /build/src/IO/ReadWriteBufferFromHTTP.cpp:277: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x000000001184a4c4 7. /build/src/IO/ReadWriteBufferFromHTTP.cpp:285: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x000000001184a615 8. /build/src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x000000001184ae59 9. /build/src/IO/ReadWriteBufferFromHTTP.cpp:472: void std::__function::__policy_invoker::__call_impl[abi:se190107]>(std::__function::__policy_storage const*) @ 0x000000001184cedd 10. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001184858b 11. /build/src/IO/ReadWriteBufferFromHTTP.cpp:465: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x000000001184bf0b 12. /build/src/IO/ReadBuffer.h:60: DB::ReadBuffer::next() @ 0x000000000a148c7b 13. /build/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) @ 0x0000000011849fb2 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]>&)>&, 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&) @ 0x0000000011841980 15. /build/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) @ 0x000000001621208e 16. /build/src/Storages/StorageReplicatedMergeTree.cpp:5228: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl[abi:se190107] const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000015f9a5fe 17. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000015ed8bfd 18. /build/src/Storages/StorageReplicatedMergeTree.cpp:2514: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x0000000015ec9aab 19. /build/src/Storages/StorageReplicatedMergeTree.cpp:2349: DB::StorageReplicatedMergeTree::executeLogEntry(DB::ReplicatedMergeTreeLogEntry&) @ 0x0000000015eba91b 20. /build/src/Storages/StorageReplicatedMergeTree.cpp:3876: bool std::__function::__policy_invoker&)>::__call_impl[abi:se190107])::$_1, bool (std::shared_ptr&)>>(std::__function::__policy_storage const*, std::shared_ptr&) @ 0x0000000015f9837e 21. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000165d6fc3 22. /build/src/Storages/StorageReplicatedMergeTree.cpp:3872: DB::StorageReplicatedMergeTree::processQueueEntry(std::shared_ptr) @ 0x0000000015efc18a 23. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001624c1b2 24. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000162f9c70 25. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x00000000162fa55a 26. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc6653 27. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000000fccc4c3 28. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc3d92 29. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fcca080 30. ? @ 0x00007fbc6213eac3 31. ? @ 0x00007fbc621d0850 (version 25.3.6.10636.altinitytest (altinity build)) 2025.07.28 11:55:35.732346 [ 3964 ] {} test_13.rmt2 (7f9b740d-015c-470e-8cc6-8ba33be0dc63): auto DB::StorageReplicatedMergeTree::processQueueEntry(ReplicatedMergeTreeQueue::SelectedEntryPtr)::(anonymous class)::operator()(LogEntryPtr &) const: Code: 86. DB::HTTPException: Received error from remote server http://146b4357c08d:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Ftest%2F01165%2Ftest_13%2Frmt%2Freplicas%2F1&part=20250728_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.6.10636.altinitytest (altinity build)) '. (RECEIVED_ERROR_FROM_REMOTE_IO_SERVER), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.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 const&, int&&, String const&, unsigned long&&, String const&) @ 0x000000000feda8d9 4. /build/src/IO/HTTPCommon.cpp:104: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x000000000feda6e2 5. /build/src/IO/HTTPCommon.cpp:93: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x000000000feda537 6. /build/src/IO/ReadWriteBufferFromHTTP.cpp:277: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x000000001184a4c4 7. /build/src/IO/ReadWriteBufferFromHTTP.cpp:285: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x000000001184a615 8. /build/src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x000000001184ae59 9. /build/src/IO/ReadWriteBufferFromHTTP.cpp:472: void std::__function::__policy_invoker::__call_impl[abi:se190107]>(std::__function::__policy_storage const*) @ 0x000000001184cedd 10. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001184858b 11. /build/src/IO/ReadWriteBufferFromHTTP.cpp:465: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x000000001184bf0b 12. /build/src/IO/ReadBuffer.h:60: DB::ReadBuffer::next() @ 0x000000000a148c7b 13. /build/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) @ 0x0000000011849fb2 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]>&)>&, 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&) @ 0x0000000011841980 15. /build/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) @ 0x000000001621208e 16. /build/src/Storages/StorageReplicatedMergeTree.cpp:5228: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl[abi:se190107] const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000015f9a5fe 17. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000015ed8bfd 18. /build/src/Storages/StorageReplicatedMergeTree.cpp:2514: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x0000000015ec9aab 19. /build/src/Storages/StorageReplicatedMergeTree.cpp:2349: DB::StorageReplicatedMergeTree::executeLogEntry(DB::ReplicatedMergeTreeLogEntry&) @ 0x0000000015eba91b 20. /build/src/Storages/StorageReplicatedMergeTree.cpp:3876: bool std::__function::__policy_invoker&)>::__call_impl[abi:se190107])::$_1, bool (std::shared_ptr&)>>(std::__function::__policy_storage const*, std::shared_ptr&) @ 0x0000000015f9837e 21. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000165d6fc3 22. /build/src/Storages/StorageReplicatedMergeTree.cpp:3872: DB::StorageReplicatedMergeTree::processQueueEntry(std::shared_ptr) @ 0x0000000015efc18a 23. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001624c1b2 24. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000162f9c70 25. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x00000000162fa55a 26. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc6653 27. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000000fccc4c3 28. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc3d92 29. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fcca080 30. ? @ 0x00007fbc6213eac3 31. ? @ 0x00007fbc621d0850 (version 25.3.6.10636.altinitytest (altinity build)) 2025.07.28 11:55:36.471728 [ 5825 ] {8f6aeb0a-f991-4003-8e31-9341b7186aa3} executeQuery: Code: 36. DB::Exception: TTL expression toDate('2020-01-01') does not depend on any of the columns of the table. (BAD_ARGUMENTS) (version 25.3.6.10636.altinitytest (altinity build)) (from [::1]:56214) (comment: 01652_ttl_old_syntax.sql) (query 4, line 5) (in query: ALTER TABLE ttl_old_syntax MODIFY TTL toDate('2020-01-01');), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000a9b78ab 4. /build/src/Storages/TTLDescription.cpp:75: DB::TTLDescription::getTTLFromAST(std::shared_ptr const&, DB::ColumnsDescription const&, std::shared_ptr, DB::KeyDescription const&, bool) @ 0x000000001603e5f8 5. /build/src/Storages/TTLDescription.cpp:401: DB::TTLTableDescription::getTTLForTableFromAST(std::shared_ptr const&, DB::ColumnsDescription const&, std::shared_ptr, DB::KeyDescription const&, bool) @ 0x000000001603f15a 6. /build/src/Storages/AlterCommands.cpp:864: DB::AlterCommand::apply(DB::StorageInMemoryMetadata&, std::shared_ptr) const @ 0x0000000015ced2e4 7. /build/src/Storages/AlterCommands.cpp:1263: DB::AlterCommands::apply(DB::StorageInMemoryMetadata&, std::shared_ptr) const @ 0x0000000015cf2c7b 8. /build/src/Storages/MergeTree/MergeTreeData.cpp:3534: DB::MergeTreeData::checkAlterIsPossible(DB::AlterCommands const&, std::shared_ptr) const @ 0x00000000163355eb 9. /build/src/Interpreters/InterpreterAlterQuery.cpp:215: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x00000000148deab3 10. /build/src/Interpreters/InterpreterAlterQuery.cpp:77: DB::InterpreterAlterQuery::execute() @ 0x00000000148dcb0d 11. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88dc9 12. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 13. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 14. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 15. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 16. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 17. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 18. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 19. ? @ 0x00007fbc6213eac3 20. ? @ 0x00007fbc621d0850 2025.07.28 11:55:36.475543 [ 5825 ] {} TCPHandler: Code: 36. DB::Exception: TTL expression toDate('2020-01-01') does not depend on any of the columns of the table. (BAD_ARGUMENTS), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000a9b78ab 4. /build/src/Storages/TTLDescription.cpp:75: DB::TTLDescription::getTTLFromAST(std::shared_ptr const&, DB::ColumnsDescription const&, std::shared_ptr, DB::KeyDescription const&, bool) @ 0x000000001603e5f8 5. /build/src/Storages/TTLDescription.cpp:401: DB::TTLTableDescription::getTTLForTableFromAST(std::shared_ptr const&, DB::ColumnsDescription const&, std::shared_ptr, DB::KeyDescription const&, bool) @ 0x000000001603f15a 6. /build/src/Storages/AlterCommands.cpp:864: DB::AlterCommand::apply(DB::StorageInMemoryMetadata&, std::shared_ptr) const @ 0x0000000015ced2e4 7. /build/src/Storages/AlterCommands.cpp:1263: DB::AlterCommands::apply(DB::StorageInMemoryMetadata&, std::shared_ptr) const @ 0x0000000015cf2c7b 8. /build/src/Storages/MergeTree/MergeTreeData.cpp:3534: DB::MergeTreeData::checkAlterIsPossible(DB::AlterCommands const&, std::shared_ptr) const @ 0x00000000163355eb 9. /build/src/Interpreters/InterpreterAlterQuery.cpp:215: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x00000000148deab3 10. /build/src/Interpreters/InterpreterAlterQuery.cpp:77: DB::InterpreterAlterQuery::execute() @ 0x00000000148dcb0d 11. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88dc9 12. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 13. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 14. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 15. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 16. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 17. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 18. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 19. ? @ 0x00007fbc6213eac3 20. ? @ 0x00007fbc621d0850 2025.07.28 11:55:36.671051 [ 17252 ] {48b7ed55-9fc2-42c8-b4d4-283905579f59} executeQuery: Code: 48. DB::Exception: ReplicatedMergeTree (table test_di2z0wst.t1 (053a0213-db34-4647-9c84-8c2abadd9a60)) does not support transactions. (NOT_IMPLEMENTED) (version 25.3.6.10636.altinitytest (altinity build)) (from [::1]:56198) (comment: 02456_alter-nullable-column-bag-2.sql) (query 3, line 3) (in query: INSERT INTO t1 values), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x000000000a06b56b 4. /build/src/Interpreters/IInterpreter.cpp:55: DB::IInterpreter::checkStorageSupportsTransactionsIfNeeded(std::shared_ptr const&, std::shared_ptr, bool) @ 0x00000000148e6f26 5. /build/src/Interpreters/InterpreterInsertQuery.cpp:830: DB::InterpreterInsertQuery::execute() @ 0x0000000014933959 6. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88dc9 7. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 8. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 9. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 10. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 11. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 12. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 13. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 14. ? @ 0x00007fbc6213eac3 15. ? @ 0x00007fbc621d0850 2025.07.28 11:55:36.680639 [ 17252 ] {} TCPHandler: Code: 48. DB::Exception: ReplicatedMergeTree (table test_di2z0wst.t1 (053a0213-db34-4647-9c84-8c2abadd9a60)) does not support transactions. (NOT_IMPLEMENTED), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x000000000a06b56b 4. /build/src/Interpreters/IInterpreter.cpp:55: DB::IInterpreter::checkStorageSupportsTransactionsIfNeeded(std::shared_ptr const&, std::shared_ptr, bool) @ 0x00000000148e6f26 5. /build/src/Interpreters/InterpreterInsertQuery.cpp:830: DB::InterpreterInsertQuery::execute() @ 0x0000000014933959 6. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88dc9 7. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 8. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 9. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 10. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 11. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 12. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 13. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 14. ? @ 0x00007fbc6213eac3 15. ? @ 0x00007fbc621d0850 2025.07.28 11:55:36.813939 [ 3965 ] {} test_13.rmt2 (7f9b740d-015c-470e-8cc6-8ba33be0dc63): auto DB::StorageReplicatedMergeTree::processQueueEntry(ReplicatedMergeTreeQueue::SelectedEntryPtr)::(anonymous class)::operator()(LogEntryPtr &) const: Code: 86. DB::HTTPException: Received error from remote server http://146b4357c08d:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Ftest%2F01165%2Ftest_13%2Frmt%2Freplicas%2F1&part=20250728_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.6.10636.altinitytest (altinity build)) '. (RECEIVED_ERROR_FROM_REMOTE_IO_SERVER), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.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 const&, int&&, String const&, unsigned long&&, String const&) @ 0x000000000feda8d9 4. /build/src/IO/HTTPCommon.cpp:104: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x000000000feda6e2 5. /build/src/IO/HTTPCommon.cpp:93: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x000000000feda537 6. /build/src/IO/ReadWriteBufferFromHTTP.cpp:277: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x000000001184a4c4 7. /build/src/IO/ReadWriteBufferFromHTTP.cpp:285: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x000000001184a615 8. /build/src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x000000001184ae59 9. /build/src/IO/ReadWriteBufferFromHTTP.cpp:472: void std::__function::__policy_invoker::__call_impl[abi:se190107]>(std::__function::__policy_storage const*) @ 0x000000001184cedd 10. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001184858b 11. /build/src/IO/ReadWriteBufferFromHTTP.cpp:465: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x000000001184bf0b 12. /build/src/IO/ReadBuffer.h:60: DB::ReadBuffer::next() @ 0x000000000a148c7b 13. /build/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) @ 0x0000000011849fb2 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]>&)>&, 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&) @ 0x0000000011841980 15. /build/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) @ 0x000000001621208e 16. /build/src/Storages/StorageReplicatedMergeTree.cpp:5228: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl[abi:se190107] const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000015f9a5fe 17. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000015ed8bfd 18. /build/src/Storages/StorageReplicatedMergeTree.cpp:2514: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x0000000015ec9aab 19. /build/src/Storages/StorageReplicatedMergeTree.cpp:2349: DB::StorageReplicatedMergeTree::executeLogEntry(DB::ReplicatedMergeTreeLogEntry&) @ 0x0000000015eba91b 20. /build/src/Storages/StorageReplicatedMergeTree.cpp:3876: bool std::__function::__policy_invoker&)>::__call_impl[abi:se190107])::$_1, bool (std::shared_ptr&)>>(std::__function::__policy_storage const*, std::shared_ptr&) @ 0x0000000015f9837e 21. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000165d6fc3 22. /build/src/Storages/StorageReplicatedMergeTree.cpp:3872: DB::StorageReplicatedMergeTree::processQueueEntry(std::shared_ptr) @ 0x0000000015efc18a 23. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001624c1b2 24. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000162f9c70 25. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x00000000162fa55a 26. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc6653 27. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000000fccc4c3 28. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc3d92 29. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fcca080 30. ? @ 0x00007fbc6213eac3 31. ? @ 0x00007fbc621d0850 (version 25.3.6.10636.altinitytest (altinity build)) 2025.07.28 11:55:36.839910 [ 17252 ] {90938a38-1a1c-486a-b612-618850d4b007} executeQuery: Code: 48. DB::Exception: ReplicatedMergeTree (table test_di2z0wst.t1 (053a0213-db34-4647-9c84-8c2abadd9a60)) does not support transactions. (NOT_IMPLEMENTED) (version 25.3.6.10636.altinitytest (altinity build)) (from [::1]:49172) (comment: 02456_alter-nullable-column-bag-2.sql) (in query: DROP DATABASE IF EXISTS test_di2z0wst SYNC ), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x000000000a06b56b 4. /build/src/Interpreters/IInterpreter.cpp:55: DB::IInterpreter::checkStorageSupportsTransactionsIfNeeded(std::shared_ptr const&, std::shared_ptr, bool) @ 0x00000000148e6f26 5. /build/src/Interpreters/InterpreterDropQuery.cpp:156: DB::InterpreterDropQuery::executeToTableImpl(std::shared_ptr const&, DB::ASTDropQuery&, std::shared_ptr&, StrongTypedef, DB::UUIDTag>&) @ 0x000000001491415d 6. /build/src/Interpreters/InterpreterDropQuery.cpp:461: DB::InterpreterDropQuery::executeToDatabaseImpl(DB::ASTDropQuery const&, std::shared_ptr&, std::vector, DB::UUIDTag>, std::allocator, DB::UUIDTag>>>&) @ 0x0000000014917707 7. /build/src/Interpreters/InterpreterDropQuery.cpp:363: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x0000000014913988 8. /build/src/Interpreters/InterpreterDropQuery.cpp:99: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000014913142 9. /build/src/Interpreters/InterpreterDropQuery.cpp:72: DB::InterpreterDropQuery::execute() @ 0x0000000014912b65 10. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88dc9 11. /build/src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x0000000014c8ca7b 12. /build/src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000001686da12 13. /build/src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x0000000016870807 14. /build/src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x0000000016907e99 15. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 16. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 17. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 18. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 19. ? @ 0x00007fbc6213eac3 20. ? @ 0x00007fbc621d0850 2025.07.28 11:55:36.842352 [ 17252 ] {90938a38-1a1c-486a-b612-618850d4b007} DynamicQueryHandler: Code: 48. DB::Exception: ReplicatedMergeTree (table test_di2z0wst.t1 (053a0213-db34-4647-9c84-8c2abadd9a60)) does not support transactions. (NOT_IMPLEMENTED), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x000000000a06b56b 4. /build/src/Interpreters/IInterpreter.cpp:55: DB::IInterpreter::checkStorageSupportsTransactionsIfNeeded(std::shared_ptr const&, std::shared_ptr, bool) @ 0x00000000148e6f26 5. /build/src/Interpreters/InterpreterDropQuery.cpp:156: DB::InterpreterDropQuery::executeToTableImpl(std::shared_ptr const&, DB::ASTDropQuery&, std::shared_ptr&, StrongTypedef, DB::UUIDTag>&) @ 0x000000001491415d 6. /build/src/Interpreters/InterpreterDropQuery.cpp:461: DB::InterpreterDropQuery::executeToDatabaseImpl(DB::ASTDropQuery const&, std::shared_ptr&, std::vector, DB::UUIDTag>, std::allocator, DB::UUIDTag>>>&) @ 0x0000000014917707 7. /build/src/Interpreters/InterpreterDropQuery.cpp:363: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x0000000014913988 8. /build/src/Interpreters/InterpreterDropQuery.cpp:99: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000014913142 9. /build/src/Interpreters/InterpreterDropQuery.cpp:72: DB::InterpreterDropQuery::execute() @ 0x0000000014912b65 10. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88dc9 11. /build/src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x0000000014c8ca7b 12. /build/src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000001686da12 13. /build/src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x0000000016870807 14. /build/src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x0000000016907e99 15. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 16. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 17. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 18. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 19. ? @ 0x00007fbc6213eac3 20. ? @ 0x00007fbc621d0850 (version 25.3.6.10636.altinitytest (altinity build)) 2025.07.28 11:55:37.329833 [ 3972 ] {} test_13.rmt2 (7f9b740d-015c-470e-8cc6-8ba33be0dc63): auto DB::StorageReplicatedMergeTree::processQueueEntry(ReplicatedMergeTreeQueue::SelectedEntryPtr)::(anonymous class)::operator()(LogEntryPtr &) const: Code: 86. DB::HTTPException: Received error from remote server http://146b4357c08d:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Ftest%2F01165%2Ftest_13%2Frmt%2Freplicas%2F1&part=20250728_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.6.10636.altinitytest (altinity build)) '. (RECEIVED_ERROR_FROM_REMOTE_IO_SERVER), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.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 const&, int&&, String const&, unsigned long&&, String const&) @ 0x000000000feda8d9 4. /build/src/IO/HTTPCommon.cpp:104: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x000000000feda6e2 5. /build/src/IO/HTTPCommon.cpp:93: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x000000000feda537 6. /build/src/IO/ReadWriteBufferFromHTTP.cpp:277: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x000000001184a4c4 7. /build/src/IO/ReadWriteBufferFromHTTP.cpp:285: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x000000001184a615 8. /build/src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x000000001184ae59 9. /build/src/IO/ReadWriteBufferFromHTTP.cpp:472: void std::__function::__policy_invoker::__call_impl[abi:se190107]>(std::__function::__policy_storage const*) @ 0x000000001184cedd 10. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001184858b 11. /build/src/IO/ReadWriteBufferFromHTTP.cpp:465: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x000000001184bf0b 12. /build/src/IO/ReadBuffer.h:60: DB::ReadBuffer::next() @ 0x000000000a148c7b 13. /build/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) @ 0x0000000011849fb2 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]>&)>&, 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&) @ 0x0000000011841980 15. /build/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) @ 0x000000001621208e 16. /build/src/Storages/StorageReplicatedMergeTree.cpp:5228: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl[abi:se190107] const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000015f9a5fe 17. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000015ed8bfd 18. /build/src/Storages/StorageReplicatedMergeTree.cpp:2514: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x0000000015ec9aab 19. /build/src/Storages/StorageReplicatedMergeTree.cpp:2349: DB::StorageReplicatedMergeTree::executeLogEntry(DB::ReplicatedMergeTreeLogEntry&) @ 0x0000000015eba91b 20. /build/src/Storages/StorageReplicatedMergeTree.cpp:3876: bool std::__function::__policy_invoker&)>::__call_impl[abi:se190107])::$_1, bool (std::shared_ptr&)>>(std::__function::__policy_storage const*, std::shared_ptr&) @ 0x0000000015f9837e 21. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000165d6fc3 22. /build/src/Storages/StorageReplicatedMergeTree.cpp:3872: DB::StorageReplicatedMergeTree::processQueueEntry(std::shared_ptr) @ 0x0000000015efc18a 23. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001624c1b2 24. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000162f9c70 25. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x00000000162fa55a 26. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc6653 27. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000000fccc4c3 28. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc3d92 29. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fcca080 30. ? @ 0x00007fbc6213eac3 31. ? @ 0x00007fbc621d0850 (version 25.3.6.10636.altinitytest (altinity build)) 2025.07.28 11:55:37.385476 [ 5825 ] {8c4e121f-8e5f-4800-a872-47a50da5ec15} executeQuery: Code: 36. DB::Exception: Cannot turn rows into a ORC format strings. formatRow function supports only row output formats. (BAD_ARGUMENTS) (version 25.3.6.10636.altinitytest (altinity build)) (from [::1]:56228) (comment: 02113_format_row_bug.sql) (query 1, line 3) (in query: select formatRow('ORC', number, toDate(number)) from numbers(5);), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x000000000a6a1e2b 4. /build/src/Functions/formatRow.cpp:86: DB::(anonymous namespace)::FunctionFormatRow::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000b9a4fde 5. /build/src/Functions/IFunction.h:437: DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000a069f2a 6. /build/src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000012d9965a 7. /build/src/Functions/IFunction.cpp:351: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d93b02 8. /build/src/Functions/IFunction.cpp:420: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d95059 9. /build/src/Functions/IFunction.cpp:498: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d95c72 10. /build/src/Interpreters/ActionsDAG.cpp:812: DB::ActionsDAG::evaluatePartialResult(std::unordered_map, std::equal_to, std::allocator>>&, std::vector> const&, unsigned long, bool) @ 0x0000000013fa38cc 11. /build/src/Interpreters/ActionsDAG.cpp:892: DB::ActionsDAG::updateHeader(DB::Block const&) const @ 0x0000000013fa29a8 12. /build/src/Processors/Transforms/ExpressionTransform.cpp:10: DB::ExpressionTransform::transformHeader(DB::Block const&, DB::ActionsDAG const&) @ 0x0000000016c0afd2 13. /build/src/Processors/QueryPlan/ExpressionStep.cpp:38: DB::ExpressionStep::ExpressionStep(DB::Block const&, DB::ActionsDAG) @ 0x0000000016db8ad1 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107](DB::Block const&, DB::ActionsDAG&&) @ 0x00000000131ee01a 15. /build/src/Planner/Planner.cpp:392: DB::(anonymous namespace)::addExpressionStep(DB::QueryPlan&, std::shared_ptr&, String const&, std::unordered_set, std::hash>, std::equal_to>, std::allocator>>&) @ 0x000000001498191d 16. /build/src/Planner/Planner.cpp:1648: DB::Planner::buildPlanForQueryNode() @ 0x000000001497b7aa 17. /build/src/Planner/Planner.cpp:1308: DB::Planner::buildQueryPlanIfNeeded() @ 0x000000001497685c 18. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:255: DB::InterpreterSelectQueryAnalyzer::getQueryPlan() @ 0x000000001497476d 19. /build/src/Interpreters/executeQuery.cpp:1405: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88806 20. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 21. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 22. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 23. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 24. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 25. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 26. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 27. ? @ 0x00007fbc6213eac3 28. ? @ 0x00007fbc621d0850 2025.07.28 11:55:37.388831 [ 5825 ] {} TCPHandler: Code: 36. DB::Exception: Cannot turn rows into a ORC format strings. formatRow function supports only row output formats. (BAD_ARGUMENTS), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x000000000a6a1e2b 4. /build/src/Functions/formatRow.cpp:86: DB::(anonymous namespace)::FunctionFormatRow::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000b9a4fde 5. /build/src/Functions/IFunction.h:437: DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000a069f2a 6. /build/src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000012d9965a 7. /build/src/Functions/IFunction.cpp:351: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d93b02 8. /build/src/Functions/IFunction.cpp:420: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d95059 9. /build/src/Functions/IFunction.cpp:498: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d95c72 10. /build/src/Interpreters/ActionsDAG.cpp:812: DB::ActionsDAG::evaluatePartialResult(std::unordered_map, std::equal_to, std::allocator>>&, std::vector> const&, unsigned long, bool) @ 0x0000000013fa38cc 11. /build/src/Interpreters/ActionsDAG.cpp:892: DB::ActionsDAG::updateHeader(DB::Block const&) const @ 0x0000000013fa29a8 12. /build/src/Processors/Transforms/ExpressionTransform.cpp:10: DB::ExpressionTransform::transformHeader(DB::Block const&, DB::ActionsDAG const&) @ 0x0000000016c0afd2 13. /build/src/Processors/QueryPlan/ExpressionStep.cpp:38: DB::ExpressionStep::ExpressionStep(DB::Block const&, DB::ActionsDAG) @ 0x0000000016db8ad1 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107](DB::Block const&, DB::ActionsDAG&&) @ 0x00000000131ee01a 15. /build/src/Planner/Planner.cpp:392: DB::(anonymous namespace)::addExpressionStep(DB::QueryPlan&, std::shared_ptr&, String const&, std::unordered_set, std::hash>, std::equal_to>, std::allocator>>&) @ 0x000000001498191d 16. /build/src/Planner/Planner.cpp:1648: DB::Planner::buildPlanForQueryNode() @ 0x000000001497b7aa 17. /build/src/Planner/Planner.cpp:1308: DB::Planner::buildQueryPlanIfNeeded() @ 0x000000001497685c 18. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:255: DB::InterpreterSelectQueryAnalyzer::getQueryPlan() @ 0x000000001497476d 19. /build/src/Interpreters/executeQuery.cpp:1405: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88806 20. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 21. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 22. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 23. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 24. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 25. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 26. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 27. ? @ 0x00007fbc6213eac3 28. ? @ 0x00007fbc621d0850 2025.07.28 11:55:37.412854 [ 5825 ] {6386243a-3341-4424-bb5a-944902687206} executeQuery: Code: 36. DB::Exception: Cannot turn rows into a Parquet format strings. formatRow function supports only row output formats. (BAD_ARGUMENTS) (version 25.3.6.10636.altinitytest (altinity build)) (from [::1]:56228) (comment: 02113_format_row_bug.sql) (query 2, line 4) (in query: select formatRow('Parquet', number, toDate(number)) from numbers(5);), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x000000000a6a1e2b 4. /build/src/Functions/formatRow.cpp:86: DB::(anonymous namespace)::FunctionFormatRow::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000b9a4fde 5. /build/src/Functions/IFunction.h:437: DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000a069f2a 6. /build/src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000012d9965a 7. /build/src/Functions/IFunction.cpp:351: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d93b02 8. /build/src/Functions/IFunction.cpp:420: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d95059 9. /build/src/Functions/IFunction.cpp:498: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d95c72 10. /build/src/Interpreters/ActionsDAG.cpp:812: DB::ActionsDAG::evaluatePartialResult(std::unordered_map, std::equal_to, std::allocator>>&, std::vector> const&, unsigned long, bool) @ 0x0000000013fa38cc 11. /build/src/Interpreters/ActionsDAG.cpp:892: DB::ActionsDAG::updateHeader(DB::Block const&) const @ 0x0000000013fa29a8 12. /build/src/Processors/Transforms/ExpressionTransform.cpp:10: DB::ExpressionTransform::transformHeader(DB::Block const&, DB::ActionsDAG const&) @ 0x0000000016c0afd2 13. /build/src/Processors/QueryPlan/ExpressionStep.cpp:38: DB::ExpressionStep::ExpressionStep(DB::Block const&, DB::ActionsDAG) @ 0x0000000016db8ad1 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107](DB::Block const&, DB::ActionsDAG&&) @ 0x00000000131ee01a 15. /build/src/Planner/Planner.cpp:392: DB::(anonymous namespace)::addExpressionStep(DB::QueryPlan&, std::shared_ptr&, String const&, std::unordered_set, std::hash>, std::equal_to>, std::allocator>>&) @ 0x000000001498191d 16. /build/src/Planner/Planner.cpp:1648: DB::Planner::buildPlanForQueryNode() @ 0x000000001497b7aa 17. /build/src/Planner/Planner.cpp:1308: DB::Planner::buildQueryPlanIfNeeded() @ 0x000000001497685c 18. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:255: DB::InterpreterSelectQueryAnalyzer::getQueryPlan() @ 0x000000001497476d 19. /build/src/Interpreters/executeQuery.cpp:1405: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88806 20. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 21. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 22. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 23. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 24. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 25. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 26. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 27. ? @ 0x00007fbc6213eac3 28. ? @ 0x00007fbc621d0850 2025.07.28 11:55:37.415829 [ 5825 ] {} TCPHandler: Code: 36. DB::Exception: Cannot turn rows into a Parquet format strings. formatRow function supports only row output formats. (BAD_ARGUMENTS), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x000000000a6a1e2b 4. /build/src/Functions/formatRow.cpp:86: DB::(anonymous namespace)::FunctionFormatRow::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000b9a4fde 5. /build/src/Functions/IFunction.h:437: DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000a069f2a 6. /build/src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000012d9965a 7. /build/src/Functions/IFunction.cpp:351: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d93b02 8. /build/src/Functions/IFunction.cpp:420: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d95059 9. /build/src/Functions/IFunction.cpp:498: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d95c72 10. /build/src/Interpreters/ActionsDAG.cpp:812: DB::ActionsDAG::evaluatePartialResult(std::unordered_map, std::equal_to, std::allocator>>&, std::vector> const&, unsigned long, bool) @ 0x0000000013fa38cc 11. /build/src/Interpreters/ActionsDAG.cpp:892: DB::ActionsDAG::updateHeader(DB::Block const&) const @ 0x0000000013fa29a8 12. /build/src/Processors/Transforms/ExpressionTransform.cpp:10: DB::ExpressionTransform::transformHeader(DB::Block const&, DB::ActionsDAG const&) @ 0x0000000016c0afd2 13. /build/src/Processors/QueryPlan/ExpressionStep.cpp:38: DB::ExpressionStep::ExpressionStep(DB::Block const&, DB::ActionsDAG) @ 0x0000000016db8ad1 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107](DB::Block const&, DB::ActionsDAG&&) @ 0x00000000131ee01a 15. /build/src/Planner/Planner.cpp:392: DB::(anonymous namespace)::addExpressionStep(DB::QueryPlan&, std::shared_ptr&, String const&, std::unordered_set, std::hash>, std::equal_to>, std::allocator>>&) @ 0x000000001498191d 16. /build/src/Planner/Planner.cpp:1648: DB::Planner::buildPlanForQueryNode() @ 0x000000001497b7aa 17. /build/src/Planner/Planner.cpp:1308: DB::Planner::buildQueryPlanIfNeeded() @ 0x000000001497685c 18. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:255: DB::InterpreterSelectQueryAnalyzer::getQueryPlan() @ 0x000000001497476d 19. /build/src/Interpreters/executeQuery.cpp:1405: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88806 20. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 21. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 22. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 23. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 24. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 25. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 26. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 27. ? @ 0x00007fbc6213eac3 28. ? @ 0x00007fbc621d0850 2025.07.28 11:55:37.463941 [ 5825 ] {11b877bc-70b2-4bb8-9f37-0da977865215} executeQuery: Code: 36. DB::Exception: Cannot turn rows into a Arrow format strings. formatRow function supports only row output formats. (BAD_ARGUMENTS) (version 25.3.6.10636.altinitytest (altinity build)) (from [::1]:56228) (comment: 02113_format_row_bug.sql) (query 3, line 5) (in query: select formatRow('Arrow', number, toDate(number)) from numbers(5);), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x000000000a6a1e2b 4. /build/src/Functions/formatRow.cpp:86: DB::(anonymous namespace)::FunctionFormatRow::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000b9a4fde 5. /build/src/Functions/IFunction.h:437: DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000a069f2a 6. /build/src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000012d9965a 7. /build/src/Functions/IFunction.cpp:351: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d93b02 8. /build/src/Functions/IFunction.cpp:420: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d95059 9. /build/src/Functions/IFunction.cpp:498: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d95c72 10. /build/src/Interpreters/ActionsDAG.cpp:812: DB::ActionsDAG::evaluatePartialResult(std::unordered_map, std::equal_to, std::allocator>>&, std::vector> const&, unsigned long, bool) @ 0x0000000013fa38cc 11. /build/src/Interpreters/ActionsDAG.cpp:892: DB::ActionsDAG::updateHeader(DB::Block const&) const @ 0x0000000013fa29a8 12. /build/src/Processors/Transforms/ExpressionTransform.cpp:10: DB::ExpressionTransform::transformHeader(DB::Block const&, DB::ActionsDAG const&) @ 0x0000000016c0afd2 13. /build/src/Processors/QueryPlan/ExpressionStep.cpp:38: DB::ExpressionStep::ExpressionStep(DB::Block const&, DB::ActionsDAG) @ 0x0000000016db8ad1 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107](DB::Block const&, DB::ActionsDAG&&) @ 0x00000000131ee01a 15. /build/src/Planner/Planner.cpp:392: DB::(anonymous namespace)::addExpressionStep(DB::QueryPlan&, std::shared_ptr&, String const&, std::unordered_set, std::hash>, std::equal_to>, std::allocator>>&) @ 0x000000001498191d 16. /build/src/Planner/Planner.cpp:1648: DB::Planner::buildPlanForQueryNode() @ 0x000000001497b7aa 17. /build/src/Planner/Planner.cpp:1308: DB::Planner::buildQueryPlanIfNeeded() @ 0x000000001497685c 18. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:255: DB::InterpreterSelectQueryAnalyzer::getQueryPlan() @ 0x000000001497476d 19. /build/src/Interpreters/executeQuery.cpp:1405: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88806 20. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 21. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 22. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 23. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 24. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 25. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 26. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 27. ? @ 0x00007fbc6213eac3 28. ? @ 0x00007fbc621d0850 2025.07.28 11:55:37.467280 [ 5825 ] {} TCPHandler: Code: 36. DB::Exception: Cannot turn rows into a Arrow format strings. formatRow function supports only row output formats. (BAD_ARGUMENTS), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x000000000a6a1e2b 4. /build/src/Functions/formatRow.cpp:86: DB::(anonymous namespace)::FunctionFormatRow::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000b9a4fde 5. /build/src/Functions/IFunction.h:437: DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000a069f2a 6. /build/src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000012d9965a 7. /build/src/Functions/IFunction.cpp:351: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d93b02 8. /build/src/Functions/IFunction.cpp:420: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d95059 9. /build/src/Functions/IFunction.cpp:498: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d95c72 10. /build/src/Interpreters/ActionsDAG.cpp:812: DB::ActionsDAG::evaluatePartialResult(std::unordered_map, std::equal_to, std::allocator>>&, std::vector> const&, unsigned long, bool) @ 0x0000000013fa38cc 11. /build/src/Interpreters/ActionsDAG.cpp:892: DB::ActionsDAG::updateHeader(DB::Block const&) const @ 0x0000000013fa29a8 12. /build/src/Processors/Transforms/ExpressionTransform.cpp:10: DB::ExpressionTransform::transformHeader(DB::Block const&, DB::ActionsDAG const&) @ 0x0000000016c0afd2 13. /build/src/Processors/QueryPlan/ExpressionStep.cpp:38: DB::ExpressionStep::ExpressionStep(DB::Block const&, DB::ActionsDAG) @ 0x0000000016db8ad1 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107](DB::Block const&, DB::ActionsDAG&&) @ 0x00000000131ee01a 15. /build/src/Planner/Planner.cpp:392: DB::(anonymous namespace)::addExpressionStep(DB::QueryPlan&, std::shared_ptr&, String const&, std::unordered_set, std::hash>, std::equal_to>, std::allocator>>&) @ 0x000000001498191d 16. /build/src/Planner/Planner.cpp:1648: DB::Planner::buildPlanForQueryNode() @ 0x000000001497b7aa 17. /build/src/Planner/Planner.cpp:1308: DB::Planner::buildQueryPlanIfNeeded() @ 0x000000001497685c 18. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:255: DB::InterpreterSelectQueryAnalyzer::getQueryPlan() @ 0x000000001497476d 19. /build/src/Interpreters/executeQuery.cpp:1405: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88806 20. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 21. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 22. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 23. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 24. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 25. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 26. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 27. ? @ 0x00007fbc6213eac3 28. ? @ 0x00007fbc621d0850 2025.07.28 11:55:37.506176 [ 5825 ] {6981ff69-a7bc-4c12-8443-e0f11d56be90} executeQuery: Code: 36. DB::Exception: Cannot turn rows into a Native format strings. formatRow function supports only row output formats. (BAD_ARGUMENTS) (version 25.3.6.10636.altinitytest (altinity build)) (from [::1]:56228) (comment: 02113_format_row_bug.sql) (query 4, line 6) (in query: select formatRow('Native', number, toDate(number)) from numbers(5);), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x000000000a6a1e2b 4. /build/src/Functions/formatRow.cpp:86: DB::(anonymous namespace)::FunctionFormatRow::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000b9a4fde 5. /build/src/Functions/IFunction.h:437: DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000a069f2a 6. /build/src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000012d9965a 7. /build/src/Functions/IFunction.cpp:351: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d93b02 8. /build/src/Functions/IFunction.cpp:420: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d95059 9. /build/src/Functions/IFunction.cpp:498: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d95c72 10. /build/src/Interpreters/ActionsDAG.cpp:812: DB::ActionsDAG::evaluatePartialResult(std::unordered_map, std::equal_to, std::allocator>>&, std::vector> const&, unsigned long, bool) @ 0x0000000013fa38cc 11. /build/src/Interpreters/ActionsDAG.cpp:892: DB::ActionsDAG::updateHeader(DB::Block const&) const @ 0x0000000013fa29a8 12. /build/src/Processors/Transforms/ExpressionTransform.cpp:10: DB::ExpressionTransform::transformHeader(DB::Block const&, DB::ActionsDAG const&) @ 0x0000000016c0afd2 13. /build/src/Processors/QueryPlan/ExpressionStep.cpp:38: DB::ExpressionStep::ExpressionStep(DB::Block const&, DB::ActionsDAG) @ 0x0000000016db8ad1 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107](DB::Block const&, DB::ActionsDAG&&) @ 0x00000000131ee01a 15. /build/src/Planner/Planner.cpp:392: DB::(anonymous namespace)::addExpressionStep(DB::QueryPlan&, std::shared_ptr&, String const&, std::unordered_set, std::hash>, std::equal_to>, std::allocator>>&) @ 0x000000001498191d 16. /build/src/Planner/Planner.cpp:1648: DB::Planner::buildPlanForQueryNode() @ 0x000000001497b7aa 17. /build/src/Planner/Planner.cpp:1308: DB::Planner::buildQueryPlanIfNeeded() @ 0x000000001497685c 18. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:255: DB::InterpreterSelectQueryAnalyzer::getQueryPlan() @ 0x000000001497476d 19. /build/src/Interpreters/executeQuery.cpp:1405: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88806 20. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 21. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 22. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 23. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 24. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 25. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 26. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 27. ? @ 0x00007fbc6213eac3 28. ? @ 0x00007fbc621d0850 2025.07.28 11:55:37.509126 [ 5825 ] {} TCPHandler: Code: 36. DB::Exception: Cannot turn rows into a Native format strings. formatRow function supports only row output formats. (BAD_ARGUMENTS), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x000000000a6a1e2b 4. /build/src/Functions/formatRow.cpp:86: DB::(anonymous namespace)::FunctionFormatRow::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000b9a4fde 5. /build/src/Functions/IFunction.h:437: DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000a069f2a 6. /build/src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000012d9965a 7. /build/src/Functions/IFunction.cpp:351: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d93b02 8. /build/src/Functions/IFunction.cpp:420: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d95059 9. /build/src/Functions/IFunction.cpp:498: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d95c72 10. /build/src/Interpreters/ActionsDAG.cpp:812: DB::ActionsDAG::evaluatePartialResult(std::unordered_map, std::equal_to, std::allocator>>&, std::vector> const&, unsigned long, bool) @ 0x0000000013fa38cc 11. /build/src/Interpreters/ActionsDAG.cpp:892: DB::ActionsDAG::updateHeader(DB::Block const&) const @ 0x0000000013fa29a8 12. /build/src/Processors/Transforms/ExpressionTransform.cpp:10: DB::ExpressionTransform::transformHeader(DB::Block const&, DB::ActionsDAG const&) @ 0x0000000016c0afd2 13. /build/src/Processors/QueryPlan/ExpressionStep.cpp:38: DB::ExpressionStep::ExpressionStep(DB::Block const&, DB::ActionsDAG) @ 0x0000000016db8ad1 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107](DB::Block const&, DB::ActionsDAG&&) @ 0x00000000131ee01a 15. /build/src/Planner/Planner.cpp:392: DB::(anonymous namespace)::addExpressionStep(DB::QueryPlan&, std::shared_ptr&, String const&, std::unordered_set, std::hash>, std::equal_to>, std::allocator>>&) @ 0x000000001498191d 16. /build/src/Planner/Planner.cpp:1648: DB::Planner::buildPlanForQueryNode() @ 0x000000001497b7aa 17. /build/src/Planner/Planner.cpp:1308: DB::Planner::buildQueryPlanIfNeeded() @ 0x000000001497685c 18. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:255: DB::InterpreterSelectQueryAnalyzer::getQueryPlan() @ 0x000000001497476d 19. /build/src/Interpreters/executeQuery.cpp:1405: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88806 20. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 21. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 22. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 23. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 24. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 25. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 26. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 27. ? @ 0x00007fbc6213eac3 28. ? @ 0x00007fbc621d0850 2025.07.28 11:55:37.523337 [ 17252 ] {f26ccb22-f02f-454f-ba36-c67b1b2c1982} executeQuery: Code: 57. DB::Exception: Table test_mpm8z6d4.null_before already exists. (TABLE_ALREADY_EXISTS) (version 25.3.6.10636.altinitytest (altinity build)) (from [::1]:56226) (comment: 02302_column_decl_null_before_defaul_value.sql) (query 7, line 8) (in query: CREATE TABLE null_before (`id` INT NOT NULL) ENGINE = MergeTree ORDER BY tuple() SETTINGS index_granularity = 22128, min_bytes_for_wide_part = 1073741824, ratio_of_defaults_for_sparse_serialization = 0.27993515133857727, replace_long_file_name_to_hash = true, max_file_name_length = 70, min_bytes_for_full_part_storage = 440440208, compact_parts_max_bytes_to_buffer = 38183118, compact_parts_max_granules_to_buffer = 256, compact_parts_merge_max_bytes_to_prefetch_part = 11672348, merge_max_block_size = 3809, old_parts_lifetime = 305., prefer_fetch_merged_part_size_threshold = 1, 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 = 16369677, use_const_adaptive_granularity = true, enable_index_granularity_compression = false, concurrent_part_removal_threshold = 20, 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 = 93562, primary_key_compress_block_size = 87336, 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. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000a06a8eb 4. /build/src/Interpreters/InterpreterCreateQuery.cpp:1824: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x0000000014901d53 5. /build/src/Interpreters/InterpreterCreateQuery.cpp:1743: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000148f9aa9 6. /build/src/Interpreters/InterpreterCreateQuery.cpp:2352: DB::InterpreterCreateQuery::execute() @ 0x0000000014905a41 7. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88dc9 8. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 9. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 10. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 11. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 12. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 13. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 14. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 15. ? @ 0x00007fbc6213eac3 16. ? @ 0x00007fbc621d0850 2025.07.28 11:55:37.531382 [ 17252 ] {} TCPHandler: Code: 57. DB::Exception: Table test_mpm8z6d4.null_before already exists. (TABLE_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000a06a8eb 4. /build/src/Interpreters/InterpreterCreateQuery.cpp:1824: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x0000000014901d53 5. /build/src/Interpreters/InterpreterCreateQuery.cpp:1743: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000148f9aa9 6. /build/src/Interpreters/InterpreterCreateQuery.cpp:2352: DB::InterpreterCreateQuery::execute() @ 0x0000000014905a41 7. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88dc9 8. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 9. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 10. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 11. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 12. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 13. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 14. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 15. ? @ 0x00007fbc6213eac3 16. ? @ 0x00007fbc621d0850 2025.07.28 11:55:37.857061 [ 3961 ] {} test_13.rmt2 (7f9b740d-015c-470e-8cc6-8ba33be0dc63): auto DB::StorageReplicatedMergeTree::processQueueEntry(ReplicatedMergeTreeQueue::SelectedEntryPtr)::(anonymous class)::operator()(LogEntryPtr &) const: Code: 86. DB::HTTPException: Received error from remote server http://146b4357c08d:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Ftest%2F01165%2Ftest_13%2Frmt%2Freplicas%2F1&part=20250728_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.6.10636.altinitytest (altinity build)) '. (RECEIVED_ERROR_FROM_REMOTE_IO_SERVER), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.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 const&, int&&, String const&, unsigned long&&, String const&) @ 0x000000000feda8d9 4. /build/src/IO/HTTPCommon.cpp:104: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x000000000feda6e2 5. /build/src/IO/HTTPCommon.cpp:93: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x000000000feda537 6. /build/src/IO/ReadWriteBufferFromHTTP.cpp:277: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x000000001184a4c4 7. /build/src/IO/ReadWriteBufferFromHTTP.cpp:285: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x000000001184a615 8. /build/src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x000000001184ae59 9. /build/src/IO/ReadWriteBufferFromHTTP.cpp:472: void std::__function::__policy_invoker::__call_impl[abi:se190107]>(std::__function::__policy_storage const*) @ 0x000000001184cedd 10. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001184858b 11. /build/src/IO/ReadWriteBufferFromHTTP.cpp:465: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x000000001184bf0b 12. /build/src/IO/ReadBuffer.h:60: DB::ReadBuffer::next() @ 0x000000000a148c7b 13. /build/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) @ 0x0000000011849fb2 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]>&)>&, 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&) @ 0x0000000011841980 15. /build/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) @ 0x000000001621208e 16. /build/src/Storages/StorageReplicatedMergeTree.cpp:5228: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl[abi:se190107] const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000015f9a5fe 17. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000015ed8bfd 18. /build/src/Storages/StorageReplicatedMergeTree.cpp:2514: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x0000000015ec9aab 19. /build/src/Storages/StorageReplicatedMergeTree.cpp:2349: DB::StorageReplicatedMergeTree::executeLogEntry(DB::ReplicatedMergeTreeLogEntry&) @ 0x0000000015eba91b 20. /build/src/Storages/StorageReplicatedMergeTree.cpp:3876: bool std::__function::__policy_invoker&)>::__call_impl[abi:se190107])::$_1, bool (std::shared_ptr&)>>(std::__function::__policy_storage const*, std::shared_ptr&) @ 0x0000000015f9837e 21. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000165d6fc3 22. /build/src/Storages/StorageReplicatedMergeTree.cpp:3872: DB::StorageReplicatedMergeTree::processQueueEntry(std::shared_ptr) @ 0x0000000015efc18a 23. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001624c1b2 24. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000162f9c70 25. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x00000000162fa55a 26. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc6653 27. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000000fccc4c3 28. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc3d92 29. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fcca080 30. ? @ 0x00007fbc6213eac3 31. ? @ 0x00007fbc621d0850 (version 25.3.6.10636.altinitytest (altinity build)) 2025.07.28 11:55:38.375972 [ 3976 ] {} test_13.rmt2 (7f9b740d-015c-470e-8cc6-8ba33be0dc63): auto DB::StorageReplicatedMergeTree::processQueueEntry(ReplicatedMergeTreeQueue::SelectedEntryPtr)::(anonymous class)::operator()(LogEntryPtr &) const: Code: 86. DB::HTTPException: Received error from remote server http://146b4357c08d:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Ftest%2F01165%2Ftest_13%2Frmt%2Freplicas%2F1&part=20250728_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.6.10636.altinitytest (altinity build)) '. (RECEIVED_ERROR_FROM_REMOTE_IO_SERVER), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.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 const&, int&&, String const&, unsigned long&&, String const&) @ 0x000000000feda8d9 4. /build/src/IO/HTTPCommon.cpp:104: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x000000000feda6e2 5. /build/src/IO/HTTPCommon.cpp:93: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x000000000feda537 6. /build/src/IO/ReadWriteBufferFromHTTP.cpp:277: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x000000001184a4c4 7. /build/src/IO/ReadWriteBufferFromHTTP.cpp:285: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x000000001184a615 8. /build/src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x000000001184ae59 9. /build/src/IO/ReadWriteBufferFromHTTP.cpp:472: void std::__function::__policy_invoker::__call_impl[abi:se190107]>(std::__function::__policy_storage const*) @ 0x000000001184cedd 10. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001184858b 11. /build/src/IO/ReadWriteBufferFromHTTP.cpp:465: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x000000001184bf0b 12. /build/src/IO/ReadBuffer.h:60: DB::ReadBuffer::next() @ 0x000000000a148c7b 13. /build/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) @ 0x0000000011849fb2 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]>&)>&, 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&) @ 0x0000000011841980 15. /build/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) @ 0x000000001621208e 16. /build/src/Storages/StorageReplicatedMergeTree.cpp:5228: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl[abi:se190107] const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000015f9a5fe 17. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000015ed8bfd 18. /build/src/Storages/StorageReplicatedMergeTree.cpp:2514: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x0000000015ec9aab 19. /build/src/Storages/StorageReplicatedMergeTree.cpp:2349: DB::StorageReplicatedMergeTree::executeLogEntry(DB::ReplicatedMergeTreeLogEntry&) @ 0x0000000015eba91b 20. /build/src/Storages/StorageReplicatedMergeTree.cpp:3876: bool std::__function::__policy_invoker&)>::__call_impl[abi:se190107])::$_1, bool (std::shared_ptr&)>>(std::__function::__policy_storage const*, std::shared_ptr&) @ 0x0000000015f9837e 21. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000165d6fc3 22. /build/src/Storages/StorageReplicatedMergeTree.cpp:3872: DB::StorageReplicatedMergeTree::processQueueEntry(std::shared_ptr) @ 0x0000000015efc18a 23. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001624c1b2 24. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000162f9c70 25. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x00000000162fa55a 26. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc6653 27. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000000fccc4c3 28. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc3d92 29. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fcca080 30. ? @ 0x00007fbc6213eac3 31. ? @ 0x00007fbc621d0850 (version 25.3.6.10636.altinitytest (altinity build)) 2025.07.28 11:55:38.461981 [ 5825 ] {56027aa1-ff2b-4a30-9ec4-4773bbd6b048} executeQuery: Code: 44. DB::Exception: Illegal column '01GWJWKW30MFPQJRYEAF4XFZ9' of argument of function ULIDStringToDateTime, ULID must be 26 characters long: In scope SELECT ULIDStringToDateTime('01GWJWKW30MFPQJRYEAF4XFZ9', 'America/Costa_Rica'). (ILLEGAL_COLUMN) (version 25.3.6.10636.altinitytest (altinity build)) (from [::1]:56254) (comment: 02668_ulid_decoding.sql) (query 4, line 6) (in query: SELECT ULIDStringToDateTime('01GWJWKW30MFPQJRYEAF4XFZ9', 'America/Costa_Rica');), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, String&&, unsigned long const&) @ 0x000000000a11336b 4. /build/src/Functions/FunctionsCodingULID.cpp:126: DB::FunctionULIDStringToDateTime::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000a1191ad 5. /build/src/Functions/IFunction.h:437: DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000a069f2a 6. /build/src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000012d9965a 7. /build/src/Functions/IFunction.cpp:351: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d93b02 8. /build/src/Functions/IFunction.cpp:177: DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d93698 9. /build/src/Functions/IFunction.cpp:343: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d93aad 10. /build/src/Functions/IFunction.cpp:420: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d95059 11. /build/src/Functions/IFunction.cpp:498: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d95c72 12. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3567: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000014034494 13. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3838: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000014019a9e 14. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3980: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000014018e31 15. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:4304: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000014042fa7 16. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5605: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000014013749 17. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000140127f9 18. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000014011fce 19. /build/src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000001406ce8a 20. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000014973b42 21. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000001497268d 22. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000014974d24 23. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001492924b 24. /build/src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88641 25. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 26. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 27. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 28. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 29. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 30. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 31. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 2025.07.28 11:55:38.464976 [ 5825 ] {} TCPHandler: Code: 44. DB::Exception: Illegal column '01GWJWKW30MFPQJRYEAF4XFZ9' of argument of function ULIDStringToDateTime, ULID must be 26 characters long: In scope SELECT ULIDStringToDateTime('01GWJWKW30MFPQJRYEAF4XFZ9', 'America/Costa_Rica'). (ILLEGAL_COLUMN), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, String&&, unsigned long const&) @ 0x000000000a11336b 4. /build/src/Functions/FunctionsCodingULID.cpp:126: DB::FunctionULIDStringToDateTime::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000a1191ad 5. /build/src/Functions/IFunction.h:437: DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000a069f2a 6. /build/src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000012d9965a 7. /build/src/Functions/IFunction.cpp:351: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d93b02 8. /build/src/Functions/IFunction.cpp:177: DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d93698 9. /build/src/Functions/IFunction.cpp:343: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d93aad 10. /build/src/Functions/IFunction.cpp:420: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d95059 11. /build/src/Functions/IFunction.cpp:498: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d95c72 12. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3567: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000014034494 13. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3838: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000014019a9e 14. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3980: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000014018e31 15. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:4304: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000014042fa7 16. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5605: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000014013749 17. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000140127f9 18. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000014011fce 19. /build/src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000001406ce8a 20. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000014973b42 21. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000001497268d 22. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000014974d24 23. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001492924b 24. /build/src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88641 25. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 26. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 27. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 28. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 29. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 30. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 31. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 2025.07.28 11:55:38.555997 [ 5825 ] {3f00edd6-bdb6-4fdd-ae5b-3c23f93b1c73} executeQuery: Code: 36. DB::Exception: Cannot load time zone America/Costa_Ric: In scope SELECT ULIDStringToDateTime('01GWJWKW30MFPQJRYEAF4XFZ9E', 'America/Costa_Ric'). (BAD_ARGUMENTS) (version 25.3.6.10636.altinitytest (altinity build)) (from [::1]:56254) (comment: 02668_ulid_decoding.sql) (query 5, line 7) (in query: SELECT ULIDStringToDateTime('01GWJWKW30MFPQJRYEAF4XFZ9E', 'America/Costa_Ric');), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000a9b78ab 4. /build/src/Common/DateLUTImpl.cpp:77: DateLUTImpl::DateLUTImpl(String const&) @ 0x000000000fb9b588 5. /build/src/Common/DateLUT.cpp:200: DateLUT::getImplementation(String const&) const @ 0x000000000fb97c1e 6. /build/src/Common/DateLUT.h:37: TimezoneMixin::TimezoneMixin(String const&) @ 0x0000000013bdc5e6 7. /build/src/DataTypes/DataTypeDateTime64.cpp:22: DB::DataTypeDateTime64::DataTypeDateTime64(unsigned int, String const&) @ 0x0000000013bdc908 8. /build/contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: std::shared_ptr std::allocate_shared[abi:se190107], unsigned int const&, String&, 0>(std::allocator const&, unsigned int const&, String&) @ 0x000000000a11a126 9. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:851: DB::FunctionULIDStringToDateTime::getReturnTypeImpl(std::vector> const&) const @ 0x000000000a1195c4 10. /build/src/Functions/IFunction.cpp:645: DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x0000000012d96b0c 11. /build/src/Functions/IFunction.cpp:577: DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x0000000012d9669c 12. /build/src/Functions/IFunction.cpp:606: DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x0000000012d96edc 13. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3544: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000014033cc9 14. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3838: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000014019a9e 15. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3980: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000014018e31 16. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:4304: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000014042fa7 17. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5605: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000014013749 18. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000140127f9 19. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000014011fce 20. /build/src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000001406ce8a 21. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000014973b42 22. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000001497268d 23. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000014974d24 24. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001492924b 25. /build/src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88641 26. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 27. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 28. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 29. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 30. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 31. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 2025.07.28 11:55:38.560906 [ 5825 ] {} TCPHandler: Code: 36. DB::Exception: Cannot load time zone America/Costa_Ric: In scope SELECT ULIDStringToDateTime('01GWJWKW30MFPQJRYEAF4XFZ9E', 'America/Costa_Ric'). (BAD_ARGUMENTS), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000a9b78ab 4. /build/src/Common/DateLUTImpl.cpp:77: DateLUTImpl::DateLUTImpl(String const&) @ 0x000000000fb9b588 5. /build/src/Common/DateLUT.cpp:200: DateLUT::getImplementation(String const&) const @ 0x000000000fb97c1e 6. /build/src/Common/DateLUT.h:37: TimezoneMixin::TimezoneMixin(String const&) @ 0x0000000013bdc5e6 7. /build/src/DataTypes/DataTypeDateTime64.cpp:22: DB::DataTypeDateTime64::DataTypeDateTime64(unsigned int, String const&) @ 0x0000000013bdc908 8. /build/contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: std::shared_ptr std::allocate_shared[abi:se190107], unsigned int const&, String&, 0>(std::allocator const&, unsigned int const&, String&) @ 0x000000000a11a126 9. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:851: DB::FunctionULIDStringToDateTime::getReturnTypeImpl(std::vector> const&) const @ 0x000000000a1195c4 10. /build/src/Functions/IFunction.cpp:645: DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x0000000012d96b0c 11. /build/src/Functions/IFunction.cpp:577: DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x0000000012d9669c 12. /build/src/Functions/IFunction.cpp:606: DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x0000000012d96edc 13. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3544: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000014033cc9 14. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3838: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000014019a9e 15. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3980: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000014018e31 16. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:4304: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000014042fa7 17. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5605: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000014013749 18. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000140127f9 19. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000014011fce 20. /build/src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000001406ce8a 21. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000014973b42 22. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000001497268d 23. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000014974d24 24. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001492924b 25. /build/src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88641 26. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 27. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 28. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 29. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 30. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 31. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 2025.07.28 11:55:38.593732 [ 5825 ] {d91c9d29-5bf7-4544-9b41-a5c64c827453} executeQuery: Code: 44. DB::Exception: Illegal column '01GWJWKW30MFPQJRYEAF4XFZ9E0' of argument of function ULIDStringToDateTime, ULID must be 26 characters long: In scope SELECT ULIDStringToDateTime('01GWJWKW30MFPQJRYEAF4XFZ9E0'). (ILLEGAL_COLUMN) (version 25.3.6.10636.altinitytest (altinity build)) (from [::1]:56254) (comment: 02668_ulid_decoding.sql) (query 6, line 8) (in query: SELECT ULIDStringToDateTime('01GWJWKW30MFPQJRYEAF4XFZ9E0');), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, String&&, unsigned long const&) @ 0x000000000a11336b 4. /build/src/Functions/FunctionsCodingULID.cpp:126: DB::FunctionULIDStringToDateTime::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000a1191ad 5. /build/src/Functions/IFunction.h:437: DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000a069f2a 6. /build/src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000012d9965a 7. /build/src/Functions/IFunction.cpp:351: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d93b02 8. /build/src/Functions/IFunction.cpp:177: DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d93698 9. /build/src/Functions/IFunction.cpp:343: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d93aad 10. /build/src/Functions/IFunction.cpp:420: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d95059 11. /build/src/Functions/IFunction.cpp:498: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d95c72 12. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3567: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000014034494 13. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3838: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000014019a9e 14. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3980: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000014018e31 15. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:4304: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000014042fa7 16. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5605: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000014013749 17. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000140127f9 18. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000014011fce 19. /build/src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000001406ce8a 20. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000014973b42 21. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000001497268d 22. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000014974d24 23. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001492924b 24. /build/src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88641 25. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 26. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 27. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 28. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 29. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 30. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 31. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 2025.07.28 11:55:38.598221 [ 5825 ] {} TCPHandler: Code: 44. DB::Exception: Illegal column '01GWJWKW30MFPQJRYEAF4XFZ9E0' of argument of function ULIDStringToDateTime, ULID must be 26 characters long: In scope SELECT ULIDStringToDateTime('01GWJWKW30MFPQJRYEAF4XFZ9E0'). (ILLEGAL_COLUMN), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, String&&, unsigned long const&) @ 0x000000000a11336b 4. /build/src/Functions/FunctionsCodingULID.cpp:126: DB::FunctionULIDStringToDateTime::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000a1191ad 5. /build/src/Functions/IFunction.h:437: DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000a069f2a 6. /build/src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000012d9965a 7. /build/src/Functions/IFunction.cpp:351: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d93b02 8. /build/src/Functions/IFunction.cpp:177: DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d93698 9. /build/src/Functions/IFunction.cpp:343: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d93aad 10. /build/src/Functions/IFunction.cpp:420: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d95059 11. /build/src/Functions/IFunction.cpp:498: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d95c72 12. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3567: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000014034494 13. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3838: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000014019a9e 14. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3980: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000014018e31 15. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:4304: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000014042fa7 16. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5605: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000014013749 17. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000140127f9 18. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000014011fce 19. /build/src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000001406ce8a 20. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000014973b42 21. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000001497268d 22. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000014974d24 23. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001492924b 24. /build/src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88641 25. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 26. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 27. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 28. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 29. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 30. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 31. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 2025.07.28 11:55:38.773445 [ 5825 ] {b2b98b58-5c91-48a8-a580-d9c6892c8a01} executeQuery: Code: 43. DB::Exception: Illegal type UInt8 of argument of function ULIDStringToDateTime. Must be String or FixedString(26).: In scope SELECT ULIDStringToDateTime(1). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.6.10636.altinitytest (altinity build)) (from [::1]:56254) (comment: 02668_ulid_decoding.sql) (query 7, line 9) (in query: SELECT ULIDStringToDateTime(1);), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000a06a8eb 4. /build/src/Functions/FunctionsCodingULID.cpp:64: DB::FunctionULIDStringToDateTime::getReturnTypeImpl(std::vector> const&) const @ 0x000000000a119742 5. /build/src/Functions/IFunction.cpp:645: DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x0000000012d96b0c 6. /build/src/Functions/IFunction.cpp:577: DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x0000000012d9669c 7. /build/src/Functions/IFunction.cpp:606: DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x0000000012d96edc 8. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3544: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000014033cc9 9. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3838: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000014019a9e 10. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3980: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000014018e31 11. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:4304: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000014042fa7 12. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5605: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000014013749 13. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000140127f9 14. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000014011fce 15. /build/src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000001406ce8a 16. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000014973b42 17. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000001497268d 18. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000014974d24 19. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001492924b 20. /build/src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88641 21. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 22. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 23. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 24. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 25. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 26. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 27. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 28. ? @ 0x00007fbc6213eac3 29. ? @ 0x00007fbc621d0850 2025.07.28 11:55:38.789696 [ 5825 ] {} TCPHandler: Code: 43. DB::Exception: Illegal type UInt8 of argument of function ULIDStringToDateTime. Must be String or FixedString(26).: In scope SELECT ULIDStringToDateTime(1). (ILLEGAL_TYPE_OF_ARGUMENT), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000a06a8eb 4. /build/src/Functions/FunctionsCodingULID.cpp:64: DB::FunctionULIDStringToDateTime::getReturnTypeImpl(std::vector> const&) const @ 0x000000000a119742 5. /build/src/Functions/IFunction.cpp:645: DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x0000000012d96b0c 6. /build/src/Functions/IFunction.cpp:577: DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x0000000012d9669c 7. /build/src/Functions/IFunction.cpp:606: DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x0000000012d96edc 8. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3544: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000014033cc9 9. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3838: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000014019a9e 10. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3980: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000014018e31 11. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:4304: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000014042fa7 12. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5605: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000014013749 13. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000140127f9 14. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000014011fce 15. /build/src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000001406ce8a 16. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000014973b42 17. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000001497268d 18. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000014974d24 19. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001492924b 20. /build/src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88641 21. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 22. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 23. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 24. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 25. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 26. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 27. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 28. ? @ 0x00007fbc6213eac3 29. ? @ 0x00007fbc621d0850 2025.07.28 11:55:38.883680 [ 5825 ] {60d3fab2-04b1-43ef-9868-87a5f2f2e200} executeQuery: Code: 43. DB::Exception: Illegal type UInt8 of argument of function ULIDStringToDateTime. Must be String or FixedString(26).: In scope SELECT ULIDStringToDateTime(1, 2). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.6.10636.altinitytest (altinity build)) (from [::1]:56254) (comment: 02668_ulid_decoding.sql) (query 8, line 10) (in query: SELECT ULIDStringToDateTime(1, 2);), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000a06a8eb 4. /build/src/Functions/FunctionsCodingULID.cpp:64: DB::FunctionULIDStringToDateTime::getReturnTypeImpl(std::vector> const&) const @ 0x000000000a119742 5. /build/src/Functions/IFunction.cpp:645: DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x0000000012d96b0c 6. /build/src/Functions/IFunction.cpp:577: DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x0000000012d9669c 7. /build/src/Functions/IFunction.cpp:606: DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x0000000012d96edc 8. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3544: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000014033cc9 9. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3838: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000014019a9e 10. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3980: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000014018e31 11. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:4304: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000014042fa7 12. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5605: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000014013749 13. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000140127f9 14. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000014011fce 15. /build/src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000001406ce8a 16. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000014973b42 17. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000001497268d 18. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000014974d24 19. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001492924b 20. /build/src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88641 21. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 22. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 23. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 24. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 25. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 26. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 27. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 28. ? @ 0x00007fbc6213eac3 29. ? @ 0x00007fbc621d0850 2025.07.28 11:55:38.887766 [ 5825 ] {} TCPHandler: Code: 43. DB::Exception: Illegal type UInt8 of argument of function ULIDStringToDateTime. Must be String or FixedString(26).: In scope SELECT ULIDStringToDateTime(1, 2). (ILLEGAL_TYPE_OF_ARGUMENT), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000a06a8eb 4. /build/src/Functions/FunctionsCodingULID.cpp:64: DB::FunctionULIDStringToDateTime::getReturnTypeImpl(std::vector> const&) const @ 0x000000000a119742 5. /build/src/Functions/IFunction.cpp:645: DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x0000000012d96b0c 6. /build/src/Functions/IFunction.cpp:577: DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x0000000012d9669c 7. /build/src/Functions/IFunction.cpp:606: DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x0000000012d96edc 8. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3544: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000014033cc9 9. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3838: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000014019a9e 10. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3980: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000014018e31 11. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:4304: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000014042fa7 12. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5605: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000014013749 13. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000140127f9 14. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000014011fce 15. /build/src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000001406ce8a 16. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000014973b42 17. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000001497268d 18. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000014974d24 19. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001492924b 20. /build/src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88641 21. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 22. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 23. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 24. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 25. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 26. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 27. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 28. ? @ 0x00007fbc6213eac3 29. ? @ 0x00007fbc621d0850 2025.07.28 11:55:39.167144 [ 3974 ] {} test_13.rmt2 (7f9b740d-015c-470e-8cc6-8ba33be0dc63): auto DB::StorageReplicatedMergeTree::processQueueEntry(ReplicatedMergeTreeQueue::SelectedEntryPtr)::(anonymous class)::operator()(LogEntryPtr &) const: Code: 86. DB::HTTPException: Received error from remote server http://146b4357c08d:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Ftest%2F01165%2Ftest_13%2Frmt%2Freplicas%2F1&part=20250728_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.6.10636.altinitytest (altinity build)) '. (RECEIVED_ERROR_FROM_REMOTE_IO_SERVER), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.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 const&, int&&, String const&, unsigned long&&, String const&) @ 0x000000000feda8d9 4. /build/src/IO/HTTPCommon.cpp:104: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x000000000feda6e2 5. /build/src/IO/HTTPCommon.cpp:93: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x000000000feda537 6. /build/src/IO/ReadWriteBufferFromHTTP.cpp:277: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x000000001184a4c4 7. /build/src/IO/ReadWriteBufferFromHTTP.cpp:285: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x000000001184a615 8. /build/src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x000000001184ae59 9. /build/src/IO/ReadWriteBufferFromHTTP.cpp:472: void std::__function::__policy_invoker::__call_impl[abi:se190107]>(std::__function::__policy_storage const*) @ 0x000000001184cedd 10. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001184858b 11. /build/src/IO/ReadWriteBufferFromHTTP.cpp:465: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x000000001184bf0b 12. /build/src/IO/ReadBuffer.h:60: DB::ReadBuffer::next() @ 0x000000000a148c7b 13. /build/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) @ 0x0000000011849fb2 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]>&)>&, 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&) @ 0x0000000011841980 15. /build/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) @ 0x000000001621208e 16. /build/src/Storages/StorageReplicatedMergeTree.cpp:5228: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl[abi:se190107] const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000015f9a5fe 17. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000015ed8bfd 18. /build/src/Storages/StorageReplicatedMergeTree.cpp:2514: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x0000000015ec9aab 19. /build/src/Storages/StorageReplicatedMergeTree.cpp:2349: DB::StorageReplicatedMergeTree::executeLogEntry(DB::ReplicatedMergeTreeLogEntry&) @ 0x0000000015eba91b 20. /build/src/Storages/StorageReplicatedMergeTree.cpp:3876: bool std::__function::__policy_invoker&)>::__call_impl[abi:se190107])::$_1, bool (std::shared_ptr&)>>(std::__function::__policy_storage const*, std::shared_ptr&) @ 0x0000000015f9837e 21. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000165d6fc3 22. /build/src/Storages/StorageReplicatedMergeTree.cpp:3872: DB::StorageReplicatedMergeTree::processQueueEntry(std::shared_ptr) @ 0x0000000015efc18a 23. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001624c1b2 24. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000162f9c70 25. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x00000000162fa55a 26. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc6653 27. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000000fccc4c3 28. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc3d92 29. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fcca080 30. ? @ 0x00007fbc6213eac3 31. ? @ 0x00007fbc621d0850 (version 25.3.6.10636.altinitytest (altinity build)) 2025.07.28 11:55:40.305407 [ 3977 ] {} test_13.rmt2 (7f9b740d-015c-470e-8cc6-8ba33be0dc63): auto DB::StorageReplicatedMergeTree::processQueueEntry(ReplicatedMergeTreeQueue::SelectedEntryPtr)::(anonymous class)::operator()(LogEntryPtr &) const: Code: 86. DB::HTTPException: Received error from remote server http://146b4357c08d:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Ftest%2F01165%2Ftest_13%2Frmt%2Freplicas%2F1&part=20250728_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.6.10636.altinitytest (altinity build)) '. (RECEIVED_ERROR_FROM_REMOTE_IO_SERVER), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.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 const&, int&&, String const&, unsigned long&&, String const&) @ 0x000000000feda8d9 4. /build/src/IO/HTTPCommon.cpp:104: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x000000000feda6e2 5. /build/src/IO/HTTPCommon.cpp:93: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x000000000feda537 6. /build/src/IO/ReadWriteBufferFromHTTP.cpp:277: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x000000001184a4c4 7. /build/src/IO/ReadWriteBufferFromHTTP.cpp:285: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x000000001184a615 8. /build/src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x000000001184ae59 9. /build/src/IO/ReadWriteBufferFromHTTP.cpp:472: void std::__function::__policy_invoker::__call_impl[abi:se190107]>(std::__function::__policy_storage const*) @ 0x000000001184cedd 10. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001184858b 11. /build/src/IO/ReadWriteBufferFromHTTP.cpp:465: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x000000001184bf0b 12. /build/src/IO/ReadBuffer.h:60: DB::ReadBuffer::next() @ 0x000000000a148c7b 13. /build/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) @ 0x0000000011849fb2 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]>&)>&, 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&) @ 0x0000000011841980 15. /build/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) @ 0x000000001621208e 16. /build/src/Storages/StorageReplicatedMergeTree.cpp:5228: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl[abi:se190107] const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000015f9a5fe 17. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000015ed8bfd 18. /build/src/Storages/StorageReplicatedMergeTree.cpp:2514: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x0000000015ec9aab 19. /build/src/Storages/StorageReplicatedMergeTree.cpp:2349: DB::StorageReplicatedMergeTree::executeLogEntry(DB::ReplicatedMergeTreeLogEntry&) @ 0x0000000015eba91b 20. /build/src/Storages/StorageReplicatedMergeTree.cpp:3876: bool std::__function::__policy_invoker&)>::__call_impl[abi:se190107])::$_1, bool (std::shared_ptr&)>>(std::__function::__policy_storage const*, std::shared_ptr&) @ 0x0000000015f9837e 21. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000165d6fc3 22. /build/src/Storages/StorageReplicatedMergeTree.cpp:3872: DB::StorageReplicatedMergeTree::processQueueEntry(std::shared_ptr) @ 0x0000000015efc18a 23. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001624c1b2 24. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000162f9c70 25. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x00000000162fa55a 26. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc6653 27. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000000fccc4c3 28. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc3d92 29. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fcca080 30. ? @ 0x00007fbc6213eac3 31. ? @ 0x00007fbc621d0850 (version 25.3.6.10636.altinitytest (altinity build)) 2025.07.28 11:55:41.156450 [ 3971 ] {} test_13.rmt2 (7f9b740d-015c-470e-8cc6-8ba33be0dc63): auto DB::StorageReplicatedMergeTree::processQueueEntry(ReplicatedMergeTreeQueue::SelectedEntryPtr)::(anonymous class)::operator()(LogEntryPtr &) const: Code: 86. DB::HTTPException: Received error from remote server http://146b4357c08d:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Ftest%2F01165%2Ftest_13%2Frmt%2Freplicas%2F1&part=20250728_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.6.10636.altinitytest (altinity build)) '. (RECEIVED_ERROR_FROM_REMOTE_IO_SERVER), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.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 const&, int&&, String const&, unsigned long&&, String const&) @ 0x000000000feda8d9 4. /build/src/IO/HTTPCommon.cpp:104: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x000000000feda6e2 5. /build/src/IO/HTTPCommon.cpp:93: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x000000000feda537 6. /build/src/IO/ReadWriteBufferFromHTTP.cpp:277: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x000000001184a4c4 7. /build/src/IO/ReadWriteBufferFromHTTP.cpp:285: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x000000001184a615 8. /build/src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x000000001184ae59 9. /build/src/IO/ReadWriteBufferFromHTTP.cpp:472: void std::__function::__policy_invoker::__call_impl[abi:se190107]>(std::__function::__policy_storage const*) @ 0x000000001184cedd 10. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001184858b 11. /build/src/IO/ReadWriteBufferFromHTTP.cpp:465: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x000000001184bf0b 12. /build/src/IO/ReadBuffer.h:60: DB::ReadBuffer::next() @ 0x000000000a148c7b 13. /build/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) @ 0x0000000011849fb2 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]>&)>&, 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&) @ 0x0000000011841980 15. /build/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) @ 0x000000001621208e 16. /build/src/Storages/StorageReplicatedMergeTree.cpp:5228: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl[abi:se190107] const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000015f9a5fe 17. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000015ed8bfd 18. /build/src/Storages/StorageReplicatedMergeTree.cpp:2514: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x0000000015ec9aab 19. /build/src/Storages/StorageReplicatedMergeTree.cpp:2349: DB::StorageReplicatedMergeTree::executeLogEntry(DB::ReplicatedMergeTreeLogEntry&) @ 0x0000000015eba91b 20. /build/src/Storages/StorageReplicatedMergeTree.cpp:3876: bool std::__function::__policy_invoker&)>::__call_impl[abi:se190107])::$_1, bool (std::shared_ptr&)>>(std::__function::__policy_storage const*, std::shared_ptr&) @ 0x0000000015f9837e 21. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000165d6fc3 22. /build/src/Storages/StorageReplicatedMergeTree.cpp:3872: DB::StorageReplicatedMergeTree::processQueueEntry(std::shared_ptr) @ 0x0000000015efc18a 23. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001624c1b2 24. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000162f9c70 25. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x00000000162fa55a 26. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc6653 27. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000000fccc4c3 28. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc3d92 29. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fcca080 30. ? @ 0x00007fbc6213eac3 31. ? @ 0x00007fbc621d0850 (version 25.3.6.10636.altinitytest (altinity build)) 2025.07.28 11:55:41.731062 [ 3967 ] {} test_13.rmt2 (7f9b740d-015c-470e-8cc6-8ba33be0dc63): auto DB::StorageReplicatedMergeTree::processQueueEntry(ReplicatedMergeTreeQueue::SelectedEntryPtr)::(anonymous class)::operator()(LogEntryPtr &) const: Code: 86. DB::HTTPException: Received error from remote server http://146b4357c08d:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Ftest%2F01165%2Ftest_13%2Frmt%2Freplicas%2F1&part=20250728_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.6.10636.altinitytest (altinity build)) '. (RECEIVED_ERROR_FROM_REMOTE_IO_SERVER), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.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 const&, int&&, String const&, unsigned long&&, String const&) @ 0x000000000feda8d9 4. /build/src/IO/HTTPCommon.cpp:104: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x000000000feda6e2 5. /build/src/IO/HTTPCommon.cpp:93: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x000000000feda537 6. /build/src/IO/ReadWriteBufferFromHTTP.cpp:277: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x000000001184a4c4 7. /build/src/IO/ReadWriteBufferFromHTTP.cpp:285: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x000000001184a615 8. /build/src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x000000001184ae59 9. /build/src/IO/ReadWriteBufferFromHTTP.cpp:472: void std::__function::__policy_invoker::__call_impl[abi:se190107]>(std::__function::__policy_storage const*) @ 0x000000001184cedd 10. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001184858b 11. /build/src/IO/ReadWriteBufferFromHTTP.cpp:465: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x000000001184bf0b 12. /build/src/IO/ReadBuffer.h:60: DB::ReadBuffer::next() @ 0x000000000a148c7b 13. /build/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) @ 0x0000000011849fb2 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]>&)>&, 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&) @ 0x0000000011841980 15. /build/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) @ 0x000000001621208e 16. /build/src/Storages/StorageReplicatedMergeTree.cpp:5228: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl[abi:se190107] const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000015f9a5fe 17. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000015ed8bfd 18. /build/src/Storages/StorageReplicatedMergeTree.cpp:2514: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x0000000015ec9aab 19. /build/src/Storages/StorageReplicatedMergeTree.cpp:2349: DB::StorageReplicatedMergeTree::executeLogEntry(DB::ReplicatedMergeTreeLogEntry&) @ 0x0000000015eba91b 20. /build/src/Storages/StorageReplicatedMergeTree.cpp:3876: bool std::__function::__policy_invoker&)>::__call_impl[abi:se190107])::$_1, bool (std::shared_ptr&)>>(std::__function::__policy_storage const*, std::shared_ptr&) @ 0x0000000015f9837e 21. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000165d6fc3 22. /build/src/Storages/StorageReplicatedMergeTree.cpp:3872: DB::StorageReplicatedMergeTree::processQueueEntry(std::shared_ptr) @ 0x0000000015efc18a 23. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001624c1b2 24. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000162f9c70 25. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x00000000162fa55a 26. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc6653 27. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000000fccc4c3 28. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc3d92 29. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fcca080 30. ? @ 0x00007fbc6213eac3 31. ? @ 0x00007fbc621d0850 (version 25.3.6.10636.altinitytest (altinity build)) 2025.07.28 11:55:41.912004 [ 3968 ] {} test_13.rmt2 (7f9b740d-015c-470e-8cc6-8ba33be0dc63): auto DB::StorageReplicatedMergeTree::processQueueEntry(ReplicatedMergeTreeQueue::SelectedEntryPtr)::(anonymous class)::operator()(LogEntryPtr &) const: Code: 86. DB::HTTPException: Received error from remote server http://146b4357c08d:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Ftest%2F01165%2Ftest_13%2Frmt%2Freplicas%2F1&part=20250728_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.6.10636.altinitytest (altinity build)) '. (RECEIVED_ERROR_FROM_REMOTE_IO_SERVER), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.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 const&, int&&, String const&, unsigned long&&, String const&) @ 0x000000000feda8d9 4. /build/src/IO/HTTPCommon.cpp:104: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x000000000feda6e2 5. /build/src/IO/HTTPCommon.cpp:93: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x000000000feda537 6. /build/src/IO/ReadWriteBufferFromHTTP.cpp:277: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x000000001184a4c4 7. /build/src/IO/ReadWriteBufferFromHTTP.cpp:285: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x000000001184a615 8. /build/src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x000000001184ae59 9. /build/src/IO/ReadWriteBufferFromHTTP.cpp:472: void std::__function::__policy_invoker::__call_impl[abi:se190107]>(std::__function::__policy_storage const*) @ 0x000000001184cedd 10. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001184858b 11. /build/src/IO/ReadWriteBufferFromHTTP.cpp:465: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x000000001184bf0b 12. /build/src/IO/ReadBuffer.h:60: DB::ReadBuffer::next() @ 0x000000000a148c7b 13. /build/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) @ 0x0000000011849fb2 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]>&)>&, 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&) @ 0x0000000011841980 15. /build/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) @ 0x000000001621208e 16. /build/src/Storages/StorageReplicatedMergeTree.cpp:5228: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl[abi:se190107] const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000015f9a5fe 17. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000015ed8bfd 18. /build/src/Storages/StorageReplicatedMergeTree.cpp:2514: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x0000000015ec9aab 19. /build/src/Storages/StorageReplicatedMergeTree.cpp:2349: DB::StorageReplicatedMergeTree::executeLogEntry(DB::ReplicatedMergeTreeLogEntry&) @ 0x0000000015eba91b 20. /build/src/Storages/StorageReplicatedMergeTree.cpp:3876: bool std::__function::__policy_invoker&)>::__call_impl[abi:se190107])::$_1, bool (std::shared_ptr&)>>(std::__function::__policy_storage const*, std::shared_ptr&) @ 0x0000000015f9837e 21. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000165d6fc3 22. /build/src/Storages/StorageReplicatedMergeTree.cpp:3872: DB::StorageReplicatedMergeTree::processQueueEntry(std::shared_ptr) @ 0x0000000015efc18a 23. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001624c1b2 24. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000162f9c70 25. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x00000000162fa55a 26. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc6653 27. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000000fccc4c3 28. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc3d92 29. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fcca080 30. ? @ 0x00007fbc6213eac3 31. ? @ 0x00007fbc621d0850 (version 25.3.6.10636.altinitytest (altinity build)) 2025.07.28 11:55:42.732098 [ 3966 ] {} test_13.rmt2 (7f9b740d-015c-470e-8cc6-8ba33be0dc63): auto DB::StorageReplicatedMergeTree::processQueueEntry(ReplicatedMergeTreeQueue::SelectedEntryPtr)::(anonymous class)::operator()(LogEntryPtr &) const: Code: 86. DB::HTTPException: Received error from remote server http://146b4357c08d:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Ftest%2F01165%2Ftest_13%2Frmt%2Freplicas%2F1&part=20250728_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.6.10636.altinitytest (altinity build)) '. (RECEIVED_ERROR_FROM_REMOTE_IO_SERVER), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.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 const&, int&&, String const&, unsigned long&&, String const&) @ 0x000000000feda8d9 4. /build/src/IO/HTTPCommon.cpp:104: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x000000000feda6e2 5. /build/src/IO/HTTPCommon.cpp:93: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x000000000feda537 6. /build/src/IO/ReadWriteBufferFromHTTP.cpp:277: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x000000001184a4c4 7. /build/src/IO/ReadWriteBufferFromHTTP.cpp:285: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x000000001184a615 8. /build/src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x000000001184ae59 9. /build/src/IO/ReadWriteBufferFromHTTP.cpp:472: void std::__function::__policy_invoker::__call_impl[abi:se190107]>(std::__function::__policy_storage const*) @ 0x000000001184cedd 10. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001184858b 11. /build/src/IO/ReadWriteBufferFromHTTP.cpp:465: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x000000001184bf0b 12. /build/src/IO/ReadBuffer.h:60: DB::ReadBuffer::next() @ 0x000000000a148c7b 13. /build/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) @ 0x0000000011849fb2 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]>&)>&, 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&) @ 0x0000000011841980 15. /build/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) @ 0x000000001621208e 16. /build/src/Storages/StorageReplicatedMergeTree.cpp:5228: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl[abi:se190107] const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000015f9a5fe 17. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000015ed8bfd 18. /build/src/Storages/StorageReplicatedMergeTree.cpp:2514: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x0000000015ec9aab 19. /build/src/Storages/StorageReplicatedMergeTree.cpp:2349: DB::StorageReplicatedMergeTree::executeLogEntry(DB::ReplicatedMergeTreeLogEntry&) @ 0x0000000015eba91b 20. /build/src/Storages/StorageReplicatedMergeTree.cpp:3876: bool std::__function::__policy_invoker&)>::__call_impl[abi:se190107])::$_1, bool (std::shared_ptr&)>>(std::__function::__policy_storage const*, std::shared_ptr&) @ 0x0000000015f9837e 21. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000165d6fc3 22. /build/src/Storages/StorageReplicatedMergeTree.cpp:3872: DB::StorageReplicatedMergeTree::processQueueEntry(std::shared_ptr) @ 0x0000000015efc18a 23. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001624c1b2 24. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000162f9c70 25. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x00000000162fa55a 26. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc6653 27. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000000fccc4c3 28. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc3d92 29. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fcca080 30. ? @ 0x00007fbc6213eac3 31. ? @ 0x00007fbc621d0850 (version 25.3.6.10636.altinitytest (altinity build)) 2025.07.28 11:55:42.976353 [ 3974 ] {} test_13.rmt2 (7f9b740d-015c-470e-8cc6-8ba33be0dc63): auto DB::StorageReplicatedMergeTree::processQueueEntry(ReplicatedMergeTreeQueue::SelectedEntryPtr)::(anonymous class)::operator()(LogEntryPtr &) const: Code: 86. DB::HTTPException: Received error from remote server http://146b4357c08d:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Ftest%2F01165%2Ftest_13%2Frmt%2Freplicas%2F1&part=20250728_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.6.10636.altinitytest (altinity build)) '. (RECEIVED_ERROR_FROM_REMOTE_IO_SERVER), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.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 const&, int&&, String const&, unsigned long&&, String const&) @ 0x000000000feda8d9 4. /build/src/IO/HTTPCommon.cpp:104: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x000000000feda6e2 5. /build/src/IO/HTTPCommon.cpp:93: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x000000000feda537 6. /build/src/IO/ReadWriteBufferFromHTTP.cpp:277: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x000000001184a4c4 7. /build/src/IO/ReadWriteBufferFromHTTP.cpp:285: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x000000001184a615 8. /build/src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x000000001184ae59 9. /build/src/IO/ReadWriteBufferFromHTTP.cpp:472: void std::__function::__policy_invoker::__call_impl[abi:se190107]>(std::__function::__policy_storage const*) @ 0x000000001184cedd 10. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001184858b 11. /build/src/IO/ReadWriteBufferFromHTTP.cpp:465: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x000000001184bf0b 12. /build/src/IO/ReadBuffer.h:60: DB::ReadBuffer::next() @ 0x000000000a148c7b 13. /build/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) @ 0x0000000011849fb2 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]>&)>&, 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&) @ 0x0000000011841980 15. /build/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) @ 0x000000001621208e 16. /build/src/Storages/StorageReplicatedMergeTree.cpp:5228: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl[abi:se190107] const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000015f9a5fe 17. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000015ed8bfd 18. /build/src/Storages/StorageReplicatedMergeTree.cpp:2514: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x0000000015ec9aab 19. /build/src/Storages/StorageReplicatedMergeTree.cpp:2349: DB::StorageReplicatedMergeTree::executeLogEntry(DB::ReplicatedMergeTreeLogEntry&) @ 0x0000000015eba91b 20. /build/src/Storages/StorageReplicatedMergeTree.cpp:3876: bool std::__function::__policy_invoker&)>::__call_impl[abi:se190107])::$_1, bool (std::shared_ptr&)>>(std::__function::__policy_storage const*, std::shared_ptr&) @ 0x0000000015f9837e 21. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000165d6fc3 22. /build/src/Storages/StorageReplicatedMergeTree.cpp:3872: DB::StorageReplicatedMergeTree::processQueueEntry(std::shared_ptr) @ 0x0000000015efc18a 23. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001624c1b2 24. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000162f9c70 25. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x00000000162fa55a 26. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc6653 27. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000000fccc4c3 28. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc3d92 29. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fcca080 30. ? @ 0x00007fbc6213eac3 31. ? @ 0x00007fbc621d0850 (version 25.3.6.10636.altinitytest (altinity build)) 2025.07.28 11:55:43.258787 [ 3977 ] {} test_13.rmt2 (7f9b740d-015c-470e-8cc6-8ba33be0dc63): auto DB::StorageReplicatedMergeTree::processQueueEntry(ReplicatedMergeTreeQueue::SelectedEntryPtr)::(anonymous class)::operator()(LogEntryPtr &) const: Code: 86. DB::HTTPException: Received error from remote server http://146b4357c08d:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Ftest%2F01165%2Ftest_13%2Frmt%2Freplicas%2F1&part=20250728_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.6.10636.altinitytest (altinity build)) '. (RECEIVED_ERROR_FROM_REMOTE_IO_SERVER), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.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 const&, int&&, String const&, unsigned long&&, String const&) @ 0x000000000feda8d9 4. /build/src/IO/HTTPCommon.cpp:104: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x000000000feda6e2 5. /build/src/IO/HTTPCommon.cpp:93: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x000000000feda537 6. /build/src/IO/ReadWriteBufferFromHTTP.cpp:277: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x000000001184a4c4 7. /build/src/IO/ReadWriteBufferFromHTTP.cpp:285: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x000000001184a615 8. /build/src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x000000001184ae59 9. /build/src/IO/ReadWriteBufferFromHTTP.cpp:472: void std::__function::__policy_invoker::__call_impl[abi:se190107]>(std::__function::__policy_storage const*) @ 0x000000001184cedd 10. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001184858b 11. /build/src/IO/ReadWriteBufferFromHTTP.cpp:465: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x000000001184bf0b 12. /build/src/IO/ReadBuffer.h:60: DB::ReadBuffer::next() @ 0x000000000a148c7b 13. /build/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) @ 0x0000000011849fb2 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]>&)>&, 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&) @ 0x0000000011841980 15. /build/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) @ 0x000000001621208e 16. /build/src/Storages/StorageReplicatedMergeTree.cpp:5228: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl[abi:se190107] const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000015f9a5fe 17. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000015ed8bfd 18. /build/src/Storages/StorageReplicatedMergeTree.cpp:2514: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x0000000015ec9aab 19. /build/src/Storages/StorageReplicatedMergeTree.cpp:2349: DB::StorageReplicatedMergeTree::executeLogEntry(DB::ReplicatedMergeTreeLogEntry&) @ 0x0000000015eba91b 20. /build/src/Storages/StorageReplicatedMergeTree.cpp:3876: bool std::__function::__policy_invoker&)>::__call_impl[abi:se190107])::$_1, bool (std::shared_ptr&)>>(std::__function::__policy_storage const*, std::shared_ptr&) @ 0x0000000015f9837e 21. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000165d6fc3 22. /build/src/Storages/StorageReplicatedMergeTree.cpp:3872: DB::StorageReplicatedMergeTree::processQueueEntry(std::shared_ptr) @ 0x0000000015efc18a 23. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001624c1b2 24. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000162f9c70 25. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x00000000162fa55a 26. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc6653 27. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000000fccc4c3 28. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc3d92 29. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fcca080 30. ? @ 0x00007fbc6213eac3 31. ? @ 0x00007fbc621d0850 (version 25.3.6.10636.altinitytest (altinity build)) 2025.07.28 11:55:44.301292 [ 17270 ] {} 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. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception>&, String>(int, FormatStringHelperImpl>&>::type, std::type_identity::type>, std::basic_string_view>&, String&&) @ 0x000000001385a5eb 4. /build/src/Access/SettingsConstraints.cpp:376: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000013859b18 5. /build/src/Access/SettingsConstraints.cpp:300: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000013858faf 6. /build/src/Access/SettingsConstraints.cpp:209: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000013859223 7. /build/src/Interpreters/Context.cpp:2690: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000014436134 8. /build/src/Interpreters/Context.cpp:2729: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x000000001443662b 9. /build/src/Server/HTTPHandler.cpp:457: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000001686d165 10. /build/src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x0000000016870807 11. /build/src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x0000000016907e99 12. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 13. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 14. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 15. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 16. ? @ 0x00007fbc6213eac3 17. ? @ 0x00007fbc621d0850 (version 25.3.6.10636.altinitytest (altinity build)) 2025.07.28 11:55:44.362836 [ 3970 ] {} test_13.rmt2 (7f9b740d-015c-470e-8cc6-8ba33be0dc63): auto DB::StorageReplicatedMergeTree::processQueueEntry(ReplicatedMergeTreeQueue::SelectedEntryPtr)::(anonymous class)::operator()(LogEntryPtr &) const: Code: 86. DB::HTTPException: Received error from remote server http://146b4357c08d:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Ftest%2F01165%2Ftest_13%2Frmt%2Freplicas%2F1&part=20250728_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.6.10636.altinitytest (altinity build)) '. (RECEIVED_ERROR_FROM_REMOTE_IO_SERVER), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.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 const&, int&&, String const&, unsigned long&&, String const&) @ 0x000000000feda8d9 4. /build/src/IO/HTTPCommon.cpp:104: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x000000000feda6e2 5. /build/src/IO/HTTPCommon.cpp:93: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x000000000feda537 6. /build/src/IO/ReadWriteBufferFromHTTP.cpp:277: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x000000001184a4c4 7. /build/src/IO/ReadWriteBufferFromHTTP.cpp:285: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x000000001184a615 8. /build/src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x000000001184ae59 9. /build/src/IO/ReadWriteBufferFromHTTP.cpp:472: void std::__function::__policy_invoker::__call_impl[abi:se190107]>(std::__function::__policy_storage const*) @ 0x000000001184cedd 10. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001184858b 11. /build/src/IO/ReadWriteBufferFromHTTP.cpp:465: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x000000001184bf0b 12. /build/src/IO/ReadBuffer.h:60: DB::ReadBuffer::next() @ 0x000000000a148c7b 13. /build/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) @ 0x0000000011849fb2 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]>&)>&, 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&) @ 0x0000000011841980 15. /build/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) @ 0x000000001621208e 16. /build/src/Storages/StorageReplicatedMergeTree.cpp:5228: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl[abi:se190107] const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000015f9a5fe 17. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000015ed8bfd 18. /build/src/Storages/StorageReplicatedMergeTree.cpp:2514: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x0000000015ec9aab 19. /build/src/Storages/StorageReplicatedMergeTree.cpp:2349: DB::StorageReplicatedMergeTree::executeLogEntry(DB::ReplicatedMergeTreeLogEntry&) @ 0x0000000015eba91b 20. /build/src/Storages/StorageReplicatedMergeTree.cpp:3876: bool std::__function::__policy_invoker&)>::__call_impl[abi:se190107])::$_1, bool (std::shared_ptr&)>>(std::__function::__policy_storage const*, std::shared_ptr&) @ 0x0000000015f9837e 21. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000165d6fc3 22. /build/src/Storages/StorageReplicatedMergeTree.cpp:3872: DB::StorageReplicatedMergeTree::processQueueEntry(std::shared_ptr) @ 0x0000000015efc18a 23. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001624c1b2 24. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000162f9c70 25. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x00000000162fa55a 26. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc6653 27. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000000fccc4c3 28. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc3d92 29. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fcca080 30. ? @ 0x00007fbc6213eac3 31. ? @ 0x00007fbc621d0850 (version 25.3.6.10636.altinitytest (altinity build)) 2025.07.28 11:55:44.791253 [ 17270 ] {da746c89-c276-4057-b051-79f2dd685fa9} executeQuery: Code: 219. DB::Exception: New table appeared in database being dropped or detached. Try again. (DATABASE_NOT_EMPTY) (version 25.3.6.10636.altinitytest (altinity build)) (from [::1]:36766) (comment: 03208_groupArrayIntersect_serialization.sql) (in query: DROP DATABASE IF EXISTS test_jyluktbi SYNC ), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000000a074fcb 4. /build/src/Interpreters/DatabaseCatalog.cpp:608: DB::DatabaseCatalog::detachDatabase(std::shared_ptr, String const&, bool, bool) @ 0x00000000144f41b9 5. /build/src/Interpreters/InterpreterDropQuery.cpp:482: DB::InterpreterDropQuery::executeToDatabaseImpl(DB::ASTDropQuery const&, std::shared_ptr&, std::vector, DB::UUIDTag>, std::allocator, DB::UUIDTag>>>&) @ 0x00000000149179be 6. /build/src/Interpreters/InterpreterDropQuery.cpp:363: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x0000000014913988 7. /build/src/Interpreters/InterpreterDropQuery.cpp:99: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000014913142 8. /build/src/Interpreters/InterpreterDropQuery.cpp:72: DB::InterpreterDropQuery::execute() @ 0x0000000014912b65 9. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88dc9 10. /build/src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x0000000014c8ca7b 11. /build/src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000001686da12 12. /build/src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x0000000016870807 13. /build/src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x0000000016907e99 14. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 15. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 16. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 17. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 18. ? @ 0x00007fbc6213eac3 19. ? @ 0x00007fbc621d0850 2025.07.28 11:55:44.883774 [ 17270 ] {da746c89-c276-4057-b051-79f2dd685fa9} 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. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000000a074fcb 4. /build/src/Interpreters/DatabaseCatalog.cpp:608: DB::DatabaseCatalog::detachDatabase(std::shared_ptr, String const&, bool, bool) @ 0x00000000144f41b9 5. /build/src/Interpreters/InterpreterDropQuery.cpp:482: DB::InterpreterDropQuery::executeToDatabaseImpl(DB::ASTDropQuery const&, std::shared_ptr&, std::vector, DB::UUIDTag>, std::allocator, DB::UUIDTag>>>&) @ 0x00000000149179be 6. /build/src/Interpreters/InterpreterDropQuery.cpp:363: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x0000000014913988 7. /build/src/Interpreters/InterpreterDropQuery.cpp:99: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000014913142 8. /build/src/Interpreters/InterpreterDropQuery.cpp:72: DB::InterpreterDropQuery::execute() @ 0x0000000014912b65 9. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88dc9 10. /build/src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x0000000014c8ca7b 11. /build/src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000001686da12 12. /build/src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x0000000016870807 13. /build/src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x0000000016907e99 14. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 15. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 16. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 17. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 18. ? @ 0x00007fbc6213eac3 19. ? @ 0x00007fbc621d0850 (version 25.3.6.10636.altinitytest (altinity build)) 2025.07.28 11:55:45.191466 [ 3969 ] {} test_13.rmt2 (7f9b740d-015c-470e-8cc6-8ba33be0dc63): auto DB::StorageReplicatedMergeTree::processQueueEntry(ReplicatedMergeTreeQueue::SelectedEntryPtr)::(anonymous class)::operator()(LogEntryPtr &) const: Code: 86. DB::HTTPException: Received error from remote server http://146b4357c08d:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Ftest%2F01165%2Ftest_13%2Frmt%2Freplicas%2F1&part=20250728_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.6.10636.altinitytest (altinity build)) '. (RECEIVED_ERROR_FROM_REMOTE_IO_SERVER), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.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 const&, int&&, String const&, unsigned long&&, String const&) @ 0x000000000feda8d9 4. /build/src/IO/HTTPCommon.cpp:104: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x000000000feda6e2 5. /build/src/IO/HTTPCommon.cpp:93: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x000000000feda537 6. /build/src/IO/ReadWriteBufferFromHTTP.cpp:277: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x000000001184a4c4 7. /build/src/IO/ReadWriteBufferFromHTTP.cpp:285: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x000000001184a615 8. /build/src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x000000001184ae59 9. /build/src/IO/ReadWriteBufferFromHTTP.cpp:472: void std::__function::__policy_invoker::__call_impl[abi:se190107]>(std::__function::__policy_storage const*) @ 0x000000001184cedd 10. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001184858b 11. /build/src/IO/ReadWriteBufferFromHTTP.cpp:465: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x000000001184bf0b 12. /build/src/IO/ReadBuffer.h:60: DB::ReadBuffer::next() @ 0x000000000a148c7b 13. /build/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) @ 0x0000000011849fb2 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]>&)>&, 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&) @ 0x0000000011841980 15. /build/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) @ 0x000000001621208e 16. /build/src/Storages/StorageReplicatedMergeTree.cpp:5228: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl[abi:se190107] const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000015f9a5fe 17. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000015ed8bfd 18. /build/src/Storages/StorageReplicatedMergeTree.cpp:2514: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x0000000015ec9aab 19. /build/src/Storages/StorageReplicatedMergeTree.cpp:2349: DB::StorageReplicatedMergeTree::executeLogEntry(DB::ReplicatedMergeTreeLogEntry&) @ 0x0000000015eba91b 20. /build/src/Storages/StorageReplicatedMergeTree.cpp:3876: bool std::__function::__policy_invoker&)>::__call_impl[abi:se190107])::$_1, bool (std::shared_ptr&)>>(std::__function::__policy_storage const*, std::shared_ptr&) @ 0x0000000015f9837e 21. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000165d6fc3 22. /build/src/Storages/StorageReplicatedMergeTree.cpp:3872: DB::StorageReplicatedMergeTree::processQueueEntry(std::shared_ptr) @ 0x0000000015efc18a 23. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001624c1b2 24. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000162f9c70 25. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x00000000162fa55a 26. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc6653 27. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000000fccc4c3 28. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc3d92 29. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fcca080 30. ? @ 0x00007fbc6213eac3 31. ? @ 0x00007fbc621d0850 (version 25.3.6.10636.altinitytest (altinity build)) 2025.07.28 11:55:45.874083 [ 3971 ] {} test_13.rmt2 (7f9b740d-015c-470e-8cc6-8ba33be0dc63): auto DB::StorageReplicatedMergeTree::processQueueEntry(ReplicatedMergeTreeQueue::SelectedEntryPtr)::(anonymous class)::operator()(LogEntryPtr &) const: Code: 86. DB::HTTPException: Received error from remote server http://146b4357c08d:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Ftest%2F01165%2Ftest_13%2Frmt%2Freplicas%2F1&part=20250728_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.6.10636.altinitytest (altinity build)) '. (RECEIVED_ERROR_FROM_REMOTE_IO_SERVER), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.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 const&, int&&, String const&, unsigned long&&, String const&) @ 0x000000000feda8d9 4. /build/src/IO/HTTPCommon.cpp:104: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x000000000feda6e2 5. /build/src/IO/HTTPCommon.cpp:93: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x000000000feda537 6. /build/src/IO/ReadWriteBufferFromHTTP.cpp:277: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x000000001184a4c4 7. /build/src/IO/ReadWriteBufferFromHTTP.cpp:285: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x000000001184a615 8. /build/src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x000000001184ae59 9. /build/src/IO/ReadWriteBufferFromHTTP.cpp:472: void std::__function::__policy_invoker::__call_impl[abi:se190107]>(std::__function::__policy_storage const*) @ 0x000000001184cedd 10. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001184858b 11. /build/src/IO/ReadWriteBufferFromHTTP.cpp:465: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x000000001184bf0b 12. /build/src/IO/ReadBuffer.h:60: DB::ReadBuffer::next() @ 0x000000000a148c7b 13. /build/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) @ 0x0000000011849fb2 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]>&)>&, 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&) @ 0x0000000011841980 15. /build/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) @ 0x000000001621208e 16. /build/src/Storages/StorageReplicatedMergeTree.cpp:5228: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl[abi:se190107] const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000015f9a5fe 17. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000015ed8bfd 18. /build/src/Storages/StorageReplicatedMergeTree.cpp:2514: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x0000000015ec9aab 19. /build/src/Storages/StorageReplicatedMergeTree.cpp:2349: DB::StorageReplicatedMergeTree::executeLogEntry(DB::ReplicatedMergeTreeLogEntry&) @ 0x0000000015eba91b 20. /build/src/Storages/StorageReplicatedMergeTree.cpp:3876: bool std::__function::__policy_invoker&)>::__call_impl[abi:se190107])::$_1, bool (std::shared_ptr&)>>(std::__function::__policy_storage const*, std::shared_ptr&) @ 0x0000000015f9837e 21. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000165d6fc3 22. /build/src/Storages/StorageReplicatedMergeTree.cpp:3872: DB::StorageReplicatedMergeTree::processQueueEntry(std::shared_ptr) @ 0x0000000015efc18a 23. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001624c1b2 24. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000162f9c70 25. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x00000000162fa55a 26. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc6653 27. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000000fccc4c3 28. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc3d92 29. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fcca080 30. ? @ 0x00007fbc6213eac3 31. ? @ 0x00007fbc621d0850 (version 25.3.6.10636.altinitytest (altinity build)) 2025.07.28 11:55:46.178790 [ 3287 ] {9578ac68-be0b-4e6c-8383-9f2eed79079a} executeQuery: Code: 57. DB::Exception: Table test_5.test_with_merge_limit already exists. (TABLE_ALREADY_EXISTS) (version 25.3.6.10636.altinitytest (altinity build)) (from 0.0.0.0:0) (comment: 02473_optimize_old_parts.sh) (in query: /* ddl_entry=query-0000000120 */ CREATE TABLE test_5.test_with_merge_limit UUID '82230e91-6268-41eb-80af-e0ca387dd1f0' (`i` Int64) ENGINE = MergeTree PARTITION BY i ORDER BY i SETTINGS min_age_to_force_merge_seconds = 1, merge_selecting_sleep_ms = 1000, min_age_to_force_merge_on_partition_only = true, enable_max_bytes_limit_for_min_age_to_force_merge = true, max_bytes_to_merge_at_max_space_in_pool = 1, index_granularity = 22060, 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 = 536870912, compact_parts_max_bytes_to_buffer = 360170882, compact_parts_max_granules_to_buffer = 63, compact_parts_merge_max_bytes_to_prefetch_part = 23247348, merge_max_block_size = 7098, old_parts_lifetime = 367., prefer_fetch_merged_part_size_threshold = 4896656784, 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 = 20975115, 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 = 60884, primary_key_compress_block_size = 53402, 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. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000a06a8eb 4. /build/src/Interpreters/InterpreterCreateQuery.cpp:1824: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x0000000014901d53 5. /build/src/Interpreters/InterpreterCreateQuery.cpp:1743: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000148f9aa9 6. /build/src/Interpreters/InterpreterCreateQuery.cpp:2352: DB::InterpreterCreateQuery::execute() @ 0x0000000014905a41 7. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88dc9 8. /build/src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x0000000014c8ca7b 9. /build/src/Interpreters/DDLWorker.cpp:510: DB::DDLWorker::tryExecuteQuery(DB::DDLTaskBase&, std::shared_ptr const&, bool) @ 0x00000000144dab9e 10. /build/src/Interpreters/DDLWorker.cpp:675: DB::DDLWorker::processTask(DB::DDLTaskBase&, std::shared_ptr const&, bool) @ 0x00000000144d8ffe 11. /build/src/Databases/DatabaseReplicatedWorker.cpp:372: DB::DatabaseReplicatedDDLWorker::tryEnqueueAndExecuteEntry(DB::DDLLogEntry&, std::shared_ptr, bool) @ 0x0000000013dc29ab 12. /build/src/Databases/DatabaseReplicated.cpp:1139: DB::DatabaseReplicated::tryEnqueueReplicatedDDL(std::shared_ptr const&, std::shared_ptr, DB::QueryFlags) @ 0x0000000013d9f73c 13. /build/src/Interpreters/InterpreterCreateQuery.cpp:1723: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000148f96f8 14. /build/src/Interpreters/InterpreterCreateQuery.cpp:2352: DB::InterpreterCreateQuery::execute() @ 0x0000000014905a41 15. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88dc9 16. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 17. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 18. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 19. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 20. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 21. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 22. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 23. ? @ 0x00007fbc6213eac3 24. ? @ 0x00007fbc621d0850 2025.07.28 11:55:46.256351 [ 3287 ] {9578ac68-be0b-4e6c-8383-9f2eed79079a} executeQuery: Code: 57. DB::Exception: Table test_5.test_with_merge_limit already exists. (TABLE_ALREADY_EXISTS) (version 25.3.6.10636.altinitytest (altinity build)) (from [::1]:57442) (comment: 02473_optimize_old_parts.sh) (query 3, line 6) (in query: CREATE TABLE test_with_merge_limit (`i` Int64) ENGINE = MergeTree PARTITION BY i ORDER BY i SETTINGS min_age_to_force_merge_seconds = 1, merge_selecting_sleep_ms = 1000, min_age_to_force_merge_on_partition_only = true, enable_max_bytes_limit_for_min_age_to_force_merge = true, max_bytes_to_merge_at_max_space_in_pool = 1, index_granularity = 22060, 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 = 536870912, compact_parts_max_bytes_to_buffer = 360170882, compact_parts_max_granules_to_buffer = 63, compact_parts_merge_max_bytes_to_prefetch_part = 23247348, merge_max_block_size = 7098, old_parts_lifetime = 367., prefer_fetch_merged_part_size_threshold = 4896656784, 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 = 20975115, 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 = 60884, primary_key_compress_block_size = 53402, 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. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000a06a8eb 4. /build/src/Interpreters/InterpreterCreateQuery.cpp:1824: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x0000000014901d53 5. /build/src/Interpreters/InterpreterCreateQuery.cpp:1743: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000148f9aa9 6. /build/src/Interpreters/InterpreterCreateQuery.cpp:2352: DB::InterpreterCreateQuery::execute() @ 0x0000000014905a41 7. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88dc9 8. /build/src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x0000000014c8ca7b 9. /build/src/Interpreters/DDLWorker.cpp:510: DB::DDLWorker::tryExecuteQuery(DB::DDLTaskBase&, std::shared_ptr const&, bool) @ 0x00000000144dab9e 10. /build/src/Interpreters/DDLWorker.cpp:675: DB::DDLWorker::processTask(DB::DDLTaskBase&, std::shared_ptr const&, bool) @ 0x00000000144d8ffe 11. /build/src/Databases/DatabaseReplicatedWorker.cpp:372: DB::DatabaseReplicatedDDLWorker::tryEnqueueAndExecuteEntry(DB::DDLLogEntry&, std::shared_ptr, bool) @ 0x0000000013dc29ab 12. /build/src/Databases/DatabaseReplicated.cpp:1139: DB::DatabaseReplicated::tryEnqueueReplicatedDDL(std::shared_ptr const&, std::shared_ptr, DB::QueryFlags) @ 0x0000000013d9f73c 13. /build/src/Interpreters/InterpreterCreateQuery.cpp:1723: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000148f96f8 14. /build/src/Interpreters/InterpreterCreateQuery.cpp:2352: DB::InterpreterCreateQuery::execute() @ 0x0000000014905a41 15. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88dc9 16. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 17. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 18. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 19. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 20. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 21. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 22. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 23. ? @ 0x00007fbc6213eac3 24. ? @ 0x00007fbc621d0850 2025.07.28 11:55:46.281251 [ 3287 ] {} TCPHandler: Code: 57. DB::Exception: Table test_5.test_with_merge_limit already exists. (TABLE_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000a06a8eb 4. /build/src/Interpreters/InterpreterCreateQuery.cpp:1824: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x0000000014901d53 5. /build/src/Interpreters/InterpreterCreateQuery.cpp:1743: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000148f9aa9 6. /build/src/Interpreters/InterpreterCreateQuery.cpp:2352: DB::InterpreterCreateQuery::execute() @ 0x0000000014905a41 7. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88dc9 8. /build/src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x0000000014c8ca7b 9. /build/src/Interpreters/DDLWorker.cpp:510: DB::DDLWorker::tryExecuteQuery(DB::DDLTaskBase&, std::shared_ptr const&, bool) @ 0x00000000144dab9e 10. /build/src/Interpreters/DDLWorker.cpp:675: DB::DDLWorker::processTask(DB::DDLTaskBase&, std::shared_ptr const&, bool) @ 0x00000000144d8ffe 11. /build/src/Databases/DatabaseReplicatedWorker.cpp:372: DB::DatabaseReplicatedDDLWorker::tryEnqueueAndExecuteEntry(DB::DDLLogEntry&, std::shared_ptr, bool) @ 0x0000000013dc29ab 12. /build/src/Databases/DatabaseReplicated.cpp:1139: DB::DatabaseReplicated::tryEnqueueReplicatedDDL(std::shared_ptr const&, std::shared_ptr, DB::QueryFlags) @ 0x0000000013d9f73c 13. /build/src/Interpreters/InterpreterCreateQuery.cpp:1723: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000148f96f8 14. /build/src/Interpreters/InterpreterCreateQuery.cpp:2352: DB::InterpreterCreateQuery::execute() @ 0x0000000014905a41 15. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88dc9 16. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 17. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 18. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 19. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 20. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 21. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 22. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 23. ? @ 0x00007fbc6213eac3 24. ? @ 0x00007fbc621d0850 2025.07.28 11:55:46.813770 [ 3965 ] {} test_13.rmt2 (7f9b740d-015c-470e-8cc6-8ba33be0dc63): auto DB::StorageReplicatedMergeTree::processQueueEntry(ReplicatedMergeTreeQueue::SelectedEntryPtr)::(anonymous class)::operator()(LogEntryPtr &) const: Code: 86. DB::HTTPException: Received error from remote server http://146b4357c08d:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Ftest%2F01165%2Ftest_13%2Frmt%2Freplicas%2F1&part=20250728_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.6.10636.altinitytest (altinity build)) '. (RECEIVED_ERROR_FROM_REMOTE_IO_SERVER), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.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 const&, int&&, String const&, unsigned long&&, String const&) @ 0x000000000feda8d9 4. /build/src/IO/HTTPCommon.cpp:104: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x000000000feda6e2 5. /build/src/IO/HTTPCommon.cpp:93: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x000000000feda537 6. /build/src/IO/ReadWriteBufferFromHTTP.cpp:277: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x000000001184a4c4 7. /build/src/IO/ReadWriteBufferFromHTTP.cpp:285: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x000000001184a615 8. /build/src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x000000001184ae59 9. /build/src/IO/ReadWriteBufferFromHTTP.cpp:472: void std::__function::__policy_invoker::__call_impl[abi:se190107]>(std::__function::__policy_storage const*) @ 0x000000001184cedd 10. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001184858b 11. /build/src/IO/ReadWriteBufferFromHTTP.cpp:465: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x000000001184bf0b 12. /build/src/IO/ReadBuffer.h:60: DB::ReadBuffer::next() @ 0x000000000a148c7b 13. /build/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) @ 0x0000000011849fb2 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]>&)>&, 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&) @ 0x0000000011841980 15. /build/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) @ 0x000000001621208e 16. /build/src/Storages/StorageReplicatedMergeTree.cpp:5228: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl[abi:se190107] const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000015f9a5fe 17. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000015ed8bfd 18. /build/src/Storages/StorageReplicatedMergeTree.cpp:2514: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x0000000015ec9aab 19. /build/src/Storages/StorageReplicatedMergeTree.cpp:2349: DB::StorageReplicatedMergeTree::executeLogEntry(DB::ReplicatedMergeTreeLogEntry&) @ 0x0000000015eba91b 20. /build/src/Storages/StorageReplicatedMergeTree.cpp:3876: bool std::__function::__policy_invoker&)>::__call_impl[abi:se190107])::$_1, bool (std::shared_ptr&)>>(std::__function::__policy_storage const*, std::shared_ptr&) @ 0x0000000015f9837e 21. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000165d6fc3 22. /build/src/Storages/StorageReplicatedMergeTree.cpp:3872: DB::StorageReplicatedMergeTree::processQueueEntry(std::shared_ptr) @ 0x0000000015efc18a 23. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001624c1b2 24. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000162f9c70 25. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x00000000162fa55a 26. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc6653 27. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000000fccc4c3 28. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc3d92 29. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fcca080 30. ? @ 0x00007fbc6213eac3 31. ? @ 0x00007fbc621d0850 (version 25.3.6.10636.altinitytest (altinity build)) 2025.07.28 11:55:47.787534 [ 11826 ] {5655a660-1149-44cc-855b-3c9090835cc8} executeQuery: Code: 219. DB::Exception: New table appeared in database being dropped or detached. Try again. (DATABASE_NOT_EMPTY) (version 25.3.6.10636.altinitytest (altinity build)) (from [::1]:36836) (comment: 02702_logical_optimizer_with_nulls.sql) (in query: DROP DATABASE IF EXISTS test_j9dq0ewt SYNC ), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000000a074fcb 4. /build/src/Interpreters/DatabaseCatalog.cpp:608: DB::DatabaseCatalog::detachDatabase(std::shared_ptr, String const&, bool, bool) @ 0x00000000144f41b9 5. /build/src/Interpreters/InterpreterDropQuery.cpp:482: DB::InterpreterDropQuery::executeToDatabaseImpl(DB::ASTDropQuery const&, std::shared_ptr&, std::vector, DB::UUIDTag>, std::allocator, DB::UUIDTag>>>&) @ 0x00000000149179be 6. /build/src/Interpreters/InterpreterDropQuery.cpp:363: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x0000000014913988 7. /build/src/Interpreters/InterpreterDropQuery.cpp:99: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000014913142 8. /build/src/Interpreters/InterpreterDropQuery.cpp:72: DB::InterpreterDropQuery::execute() @ 0x0000000014912b65 9. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88dc9 10. /build/src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x0000000014c8ca7b 11. /build/src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000001686da12 12. /build/src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x0000000016870807 13. /build/src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x0000000016907e99 14. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 15. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 16. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 17. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 18. ? @ 0x00007fbc6213eac3 19. ? @ 0x00007fbc621d0850 2025.07.28 11:55:47.789672 [ 11826 ] {5655a660-1149-44cc-855b-3c9090835cc8} 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. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000000a074fcb 4. /build/src/Interpreters/DatabaseCatalog.cpp:608: DB::DatabaseCatalog::detachDatabase(std::shared_ptr, String const&, bool, bool) @ 0x00000000144f41b9 5. /build/src/Interpreters/InterpreterDropQuery.cpp:482: DB::InterpreterDropQuery::executeToDatabaseImpl(DB::ASTDropQuery const&, std::shared_ptr&, std::vector, DB::UUIDTag>, std::allocator, DB::UUIDTag>>>&) @ 0x00000000149179be 6. /build/src/Interpreters/InterpreterDropQuery.cpp:363: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x0000000014913988 7. /build/src/Interpreters/InterpreterDropQuery.cpp:99: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000014913142 8. /build/src/Interpreters/InterpreterDropQuery.cpp:72: DB::InterpreterDropQuery::execute() @ 0x0000000014912b65 9. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88dc9 10. /build/src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x0000000014c8ca7b 11. /build/src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000001686da12 12. /build/src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x0000000016870807 13. /build/src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x0000000016907e99 14. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 15. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 16. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 17. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 18. ? @ 0x00007fbc6213eac3 19. ? @ 0x00007fbc621d0850 (version 25.3.6.10636.altinitytest (altinity build)) 2025.07.28 11:55:47.972202 [ 3961 ] {} test_13.rmt2 (7f9b740d-015c-470e-8cc6-8ba33be0dc63): auto DB::StorageReplicatedMergeTree::processQueueEntry(ReplicatedMergeTreeQueue::SelectedEntryPtr)::(anonymous class)::operator()(LogEntryPtr &) const: Code: 86. DB::HTTPException: Received error from remote server http://146b4357c08d:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Ftest%2F01165%2Ftest_13%2Frmt%2Freplicas%2F1&part=20250728_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.6.10636.altinitytest (altinity build)) '. (RECEIVED_ERROR_FROM_REMOTE_IO_SERVER), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.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 const&, int&&, String const&, unsigned long&&, String const&) @ 0x000000000feda8d9 4. /build/src/IO/HTTPCommon.cpp:104: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x000000000feda6e2 5. /build/src/IO/HTTPCommon.cpp:93: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x000000000feda537 6. /build/src/IO/ReadWriteBufferFromHTTP.cpp:277: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x000000001184a4c4 7. /build/src/IO/ReadWriteBufferFromHTTP.cpp:285: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x000000001184a615 8. /build/src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x000000001184ae59 9. /build/src/IO/ReadWriteBufferFromHTTP.cpp:472: void std::__function::__policy_invoker::__call_impl[abi:se190107]>(std::__function::__policy_storage const*) @ 0x000000001184cedd 10. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001184858b 11. /build/src/IO/ReadWriteBufferFromHTTP.cpp:465: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x000000001184bf0b 12. /build/src/IO/ReadBuffer.h:60: DB::ReadBuffer::next() @ 0x000000000a148c7b 13. /build/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) @ 0x0000000011849fb2 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]>&)>&, 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&) @ 0x0000000011841980 15. /build/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) @ 0x000000001621208e 16. /build/src/Storages/StorageReplicatedMergeTree.cpp:5228: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl[abi:se190107] const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000015f9a5fe 17. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000015ed8bfd 18. /build/src/Storages/StorageReplicatedMergeTree.cpp:2514: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x0000000015ec9aab 19. /build/src/Storages/StorageReplicatedMergeTree.cpp:2349: DB::StorageReplicatedMergeTree::executeLogEntry(DB::ReplicatedMergeTreeLogEntry&) @ 0x0000000015eba91b 20. /build/src/Storages/StorageReplicatedMergeTree.cpp:3876: bool std::__function::__policy_invoker&)>::__call_impl[abi:se190107])::$_1, bool (std::shared_ptr&)>>(std::__function::__policy_storage const*, std::shared_ptr&) @ 0x0000000015f9837e 21. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000165d6fc3 22. /build/src/Storages/StorageReplicatedMergeTree.cpp:3872: DB::StorageReplicatedMergeTree::processQueueEntry(std::shared_ptr) @ 0x0000000015efc18a 23. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001624c1b2 24. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000162f9c70 25. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x00000000162fa55a 26. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc6653 27. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000000fccc4c3 28. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc3d92 29. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fcca080 30. ? @ 0x00007fbc6213eac3 31. ? @ 0x00007fbc621d0850 (version 25.3.6.10636.altinitytest (altinity build)) 2025.07.28 11:55:49.046303 [ 3974 ] {} test_13.rmt2 (7f9b740d-015c-470e-8cc6-8ba33be0dc63): auto DB::StorageReplicatedMergeTree::processQueueEntry(ReplicatedMergeTreeQueue::SelectedEntryPtr)::(anonymous class)::operator()(LogEntryPtr &) const: Code: 86. DB::HTTPException: Received error from remote server http://146b4357c08d:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Ftest%2F01165%2Ftest_13%2Frmt%2Freplicas%2F1&part=20250728_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.6.10636.altinitytest (altinity build)) '. (RECEIVED_ERROR_FROM_REMOTE_IO_SERVER), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.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 const&, int&&, String const&, unsigned long&&, String const&) @ 0x000000000feda8d9 4. /build/src/IO/HTTPCommon.cpp:104: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x000000000feda6e2 5. /build/src/IO/HTTPCommon.cpp:93: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x000000000feda537 6. /build/src/IO/ReadWriteBufferFromHTTP.cpp:277: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x000000001184a4c4 7. /build/src/IO/ReadWriteBufferFromHTTP.cpp:285: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x000000001184a615 8. /build/src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x000000001184ae59 9. /build/src/IO/ReadWriteBufferFromHTTP.cpp:472: void std::__function::__policy_invoker::__call_impl[abi:se190107]>(std::__function::__policy_storage const*) @ 0x000000001184cedd 10. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001184858b 11. /build/src/IO/ReadWriteBufferFromHTTP.cpp:465: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x000000001184bf0b 12. /build/src/IO/ReadBuffer.h:60: DB::ReadBuffer::next() @ 0x000000000a148c7b 13. /build/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) @ 0x0000000011849fb2 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]>&)>&, 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&) @ 0x0000000011841980 15. /build/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) @ 0x000000001621208e 16. /build/src/Storages/StorageReplicatedMergeTree.cpp:5228: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl[abi:se190107] const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000015f9a5fe 17. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000015ed8bfd 18. /build/src/Storages/StorageReplicatedMergeTree.cpp:2514: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x0000000015ec9aab 19. /build/src/Storages/StorageReplicatedMergeTree.cpp:2349: DB::StorageReplicatedMergeTree::executeLogEntry(DB::ReplicatedMergeTreeLogEntry&) @ 0x0000000015eba91b 20. /build/src/Storages/StorageReplicatedMergeTree.cpp:3876: bool std::__function::__policy_invoker&)>::__call_impl[abi:se190107])::$_1, bool (std::shared_ptr&)>>(std::__function::__policy_storage const*, std::shared_ptr&) @ 0x0000000015f9837e 21. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000165d6fc3 22. /build/src/Storages/StorageReplicatedMergeTree.cpp:3872: DB::StorageReplicatedMergeTree::processQueueEntry(std::shared_ptr) @ 0x0000000015efc18a 23. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001624c1b2 24. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000162f9c70 25. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x00000000162fa55a 26. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc6653 27. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000000fccc4c3 28. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc3d92 29. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fcca080 30. ? @ 0x00007fbc6213eac3 31. ? @ 0x00007fbc621d0850 (version 25.3.6.10636.altinitytest (altinity build)) 2025.07.28 11:55:49.522032 [ 3976 ] {} test_13.rmt2 (7f9b740d-015c-470e-8cc6-8ba33be0dc63): auto DB::StorageReplicatedMergeTree::processQueueEntry(ReplicatedMergeTreeQueue::SelectedEntryPtr)::(anonymous class)::operator()(LogEntryPtr &) const: Code: 86. DB::HTTPException: Received error from remote server http://146b4357c08d:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Ftest%2F01165%2Ftest_13%2Frmt%2Freplicas%2F1&part=20250728_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.6.10636.altinitytest (altinity build)) '. (RECEIVED_ERROR_FROM_REMOTE_IO_SERVER), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.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 const&, int&&, String const&, unsigned long&&, String const&) @ 0x000000000feda8d9 4. /build/src/IO/HTTPCommon.cpp:104: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x000000000feda6e2 5. /build/src/IO/HTTPCommon.cpp:93: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x000000000feda537 6. /build/src/IO/ReadWriteBufferFromHTTP.cpp:277: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x000000001184a4c4 7. /build/src/IO/ReadWriteBufferFromHTTP.cpp:285: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x000000001184a615 8. /build/src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x000000001184ae59 9. /build/src/IO/ReadWriteBufferFromHTTP.cpp:472: void std::__function::__policy_invoker::__call_impl[abi:se190107]>(std::__function::__policy_storage const*) @ 0x000000001184cedd 10. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001184858b 11. /build/src/IO/ReadWriteBufferFromHTTP.cpp:465: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x000000001184bf0b 12. /build/src/IO/ReadBuffer.h:60: DB::ReadBuffer::next() @ 0x000000000a148c7b 13. /build/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) @ 0x0000000011849fb2 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]>&)>&, 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&) @ 0x0000000011841980 15. /build/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) @ 0x000000001621208e 16. /build/src/Storages/StorageReplicatedMergeTree.cpp:5228: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl[abi:se190107] const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000015f9a5fe 17. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000015ed8bfd 18. /build/src/Storages/StorageReplicatedMergeTree.cpp:2514: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x0000000015ec9aab 19. /build/src/Storages/StorageReplicatedMergeTree.cpp:2349: DB::StorageReplicatedMergeTree::executeLogEntry(DB::ReplicatedMergeTreeLogEntry&) @ 0x0000000015eba91b 20. /build/src/Storages/StorageReplicatedMergeTree.cpp:3876: bool std::__function::__policy_invoker&)>::__call_impl[abi:se190107])::$_1, bool (std::shared_ptr&)>>(std::__function::__policy_storage const*, std::shared_ptr&) @ 0x0000000015f9837e 21. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000165d6fc3 22. /build/src/Storages/StorageReplicatedMergeTree.cpp:3872: DB::StorageReplicatedMergeTree::processQueueEntry(std::shared_ptr) @ 0x0000000015efc18a 23. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001624c1b2 24. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000162f9c70 25. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x00000000162fa55a 26. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc6653 27. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000000fccc4c3 28. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc3d92 29. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fcca080 30. ? @ 0x00007fbc6213eac3 31. ? @ 0x00007fbc621d0850 (version 25.3.6.10636.altinitytest (altinity build)) 2025.07.28 11:55:50.334658 [ 3977 ] {} test_13.rmt2 (7f9b740d-015c-470e-8cc6-8ba33be0dc63): auto DB::StorageReplicatedMergeTree::processQueueEntry(ReplicatedMergeTreeQueue::SelectedEntryPtr)::(anonymous class)::operator()(LogEntryPtr &) const: Code: 86. DB::HTTPException: Received error from remote server http://146b4357c08d:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Ftest%2F01165%2Ftest_13%2Frmt%2Freplicas%2F1&part=20250728_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.6.10636.altinitytest (altinity build)) '. (RECEIVED_ERROR_FROM_REMOTE_IO_SERVER), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.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 const&, int&&, String const&, unsigned long&&, String const&) @ 0x000000000feda8d9 4. /build/src/IO/HTTPCommon.cpp:104: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x000000000feda6e2 5. /build/src/IO/HTTPCommon.cpp:93: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x000000000feda537 6. /build/src/IO/ReadWriteBufferFromHTTP.cpp:277: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x000000001184a4c4 7. /build/src/IO/ReadWriteBufferFromHTTP.cpp:285: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x000000001184a615 8. /build/src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x000000001184ae59 9. /build/src/IO/ReadWriteBufferFromHTTP.cpp:472: void std::__function::__policy_invoker::__call_impl[abi:se190107]>(std::__function::__policy_storage const*) @ 0x000000001184cedd 10. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001184858b 11. /build/src/IO/ReadWriteBufferFromHTTP.cpp:465: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x000000001184bf0b 12. /build/src/IO/ReadBuffer.h:60: DB::ReadBuffer::next() @ 0x000000000a148c7b 13. /build/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) @ 0x0000000011849fb2 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]>&)>&, 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&) @ 0x0000000011841980 15. /build/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) @ 0x000000001621208e 16. /build/src/Storages/StorageReplicatedMergeTree.cpp:5228: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl[abi:se190107] const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000015f9a5fe 17. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000015ed8bfd 18. /build/src/Storages/StorageReplicatedMergeTree.cpp:2514: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x0000000015ec9aab 19. /build/src/Storages/StorageReplicatedMergeTree.cpp:2349: DB::StorageReplicatedMergeTree::executeLogEntry(DB::ReplicatedMergeTreeLogEntry&) @ 0x0000000015eba91b 20. /build/src/Storages/StorageReplicatedMergeTree.cpp:3876: bool std::__function::__policy_invoker&)>::__call_impl[abi:se190107])::$_1, bool (std::shared_ptr&)>>(std::__function::__policy_storage const*, std::shared_ptr&) @ 0x0000000015f9837e 21. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000165d6fc3 22. /build/src/Storages/StorageReplicatedMergeTree.cpp:3872: DB::StorageReplicatedMergeTree::processQueueEntry(std::shared_ptr) @ 0x0000000015efc18a 23. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001624c1b2 24. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000162f9c70 25. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x00000000162fa55a 26. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc6653 27. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000000fccc4c3 28. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc3d92 29. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fcca080 30. ? @ 0x00007fbc6213eac3 31. ? @ 0x00007fbc621d0850 (version 25.3.6.10636.altinitytest (altinity build)) 2025.07.28 11:55:50.764882 [ 3966 ] {} test_13.rmt2 (7f9b740d-015c-470e-8cc6-8ba33be0dc63): auto DB::StorageReplicatedMergeTree::processQueueEntry(ReplicatedMergeTreeQueue::SelectedEntryPtr)::(anonymous class)::operator()(LogEntryPtr &) const: Code: 86. DB::HTTPException: Received error from remote server http://146b4357c08d:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Ftest%2F01165%2Ftest_13%2Frmt%2Freplicas%2F1&part=20250728_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.6.10636.altinitytest (altinity build)) '. (RECEIVED_ERROR_FROM_REMOTE_IO_SERVER), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.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 const&, int&&, String const&, unsigned long&&, String const&) @ 0x000000000feda8d9 4. /build/src/IO/HTTPCommon.cpp:104: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x000000000feda6e2 5. /build/src/IO/HTTPCommon.cpp:93: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x000000000feda537 6. /build/src/IO/ReadWriteBufferFromHTTP.cpp:277: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x000000001184a4c4 7. /build/src/IO/ReadWriteBufferFromHTTP.cpp:285: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x000000001184a615 8. /build/src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x000000001184ae59 9. /build/src/IO/ReadWriteBufferFromHTTP.cpp:472: void std::__function::__policy_invoker::__call_impl[abi:se190107]>(std::__function::__policy_storage const*) @ 0x000000001184cedd 10. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001184858b 11. /build/src/IO/ReadWriteBufferFromHTTP.cpp:465: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x000000001184bf0b 12. /build/src/IO/ReadBuffer.h:60: DB::ReadBuffer::next() @ 0x000000000a148c7b 13. /build/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) @ 0x0000000011849fb2 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]>&)>&, 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&) @ 0x0000000011841980 15. /build/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) @ 0x000000001621208e 16. /build/src/Storages/StorageReplicatedMergeTree.cpp:5228: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl[abi:se190107] const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000015f9a5fe 17. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000015ed8bfd 18. /build/src/Storages/StorageReplicatedMergeTree.cpp:2514: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x0000000015ec9aab 19. /build/src/Storages/StorageReplicatedMergeTree.cpp:2349: DB::StorageReplicatedMergeTree::executeLogEntry(DB::ReplicatedMergeTreeLogEntry&) @ 0x0000000015eba91b 20. /build/src/Storages/StorageReplicatedMergeTree.cpp:3876: bool std::__function::__policy_invoker&)>::__call_impl[abi:se190107])::$_1, bool (std::shared_ptr&)>>(std::__function::__policy_storage const*, std::shared_ptr&) @ 0x0000000015f9837e 21. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000165d6fc3 22. /build/src/Storages/StorageReplicatedMergeTree.cpp:3872: DB::StorageReplicatedMergeTree::processQueueEntry(std::shared_ptr) @ 0x0000000015efc18a 23. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001624c1b2 24. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000162f9c70 25. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x00000000162fa55a 26. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc6653 27. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000000fccc4c3 28. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc3d92 29. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fcca080 30. ? @ 0x00007fbc6213eac3 31. ? @ 0x00007fbc621d0850 (version 25.3.6.10636.altinitytest (altinity build)) 2025.07.28 11:55:51.828733 [ 17243 ] {} 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. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception>&, String>(int, FormatStringHelperImpl>&>::type, std::type_identity::type>, std::basic_string_view>&, String&&) @ 0x000000001385a5eb 4. /build/src/Access/SettingsConstraints.cpp:376: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000013859b18 5. /build/src/Access/SettingsConstraints.cpp:300: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000013858faf 6. /build/src/Access/SettingsConstraints.cpp:209: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000013859223 7. /build/src/Interpreters/Context.cpp:2690: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000014436134 8. /build/src/Interpreters/Context.cpp:2729: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x000000001443662b 9. /build/src/Server/HTTPHandler.cpp:457: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000001686d165 10. /build/src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x0000000016870807 11. /build/src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x0000000016907e99 12. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 13. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 14. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 15. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 16. ? @ 0x00007fbc6213eac3 17. ? @ 0x00007fbc621d0850 (version 25.3.6.10636.altinitytest (altinity build)) 2025.07.28 11:55:51.876290 [ 3969 ] {} test_13.rmt2 (7f9b740d-015c-470e-8cc6-8ba33be0dc63): auto DB::StorageReplicatedMergeTree::processQueueEntry(ReplicatedMergeTreeQueue::SelectedEntryPtr)::(anonymous class)::operator()(LogEntryPtr &) const: Code: 86. DB::HTTPException: Received error from remote server http://146b4357c08d:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Ftest%2F01165%2Ftest_13%2Frmt%2Freplicas%2F1&part=20250728_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.6.10636.altinitytest (altinity build)) '. (RECEIVED_ERROR_FROM_REMOTE_IO_SERVER), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.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 const&, int&&, String const&, unsigned long&&, String const&) @ 0x000000000feda8d9 4. /build/src/IO/HTTPCommon.cpp:104: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x000000000feda6e2 5. /build/src/IO/HTTPCommon.cpp:93: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x000000000feda537 6. /build/src/IO/ReadWriteBufferFromHTTP.cpp:277: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x000000001184a4c4 7. /build/src/IO/ReadWriteBufferFromHTTP.cpp:285: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x000000001184a615 8. /build/src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x000000001184ae59 9. /build/src/IO/ReadWriteBufferFromHTTP.cpp:472: void std::__function::__policy_invoker::__call_impl[abi:se190107]>(std::__function::__policy_storage const*) @ 0x000000001184cedd 10. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001184858b 11. /build/src/IO/ReadWriteBufferFromHTTP.cpp:465: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x000000001184bf0b 12. /build/src/IO/ReadBuffer.h:60: DB::ReadBuffer::next() @ 0x000000000a148c7b 13. /build/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) @ 0x0000000011849fb2 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]>&)>&, 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&) @ 0x0000000011841980 15. /build/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) @ 0x000000001621208e 16. /build/src/Storages/StorageReplicatedMergeTree.cpp:5228: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl[abi:se190107] const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000015f9a5fe 17. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000015ed8bfd 18. /build/src/Storages/StorageReplicatedMergeTree.cpp:2514: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x0000000015ec9aab 19. /build/src/Storages/StorageReplicatedMergeTree.cpp:2349: DB::StorageReplicatedMergeTree::executeLogEntry(DB::ReplicatedMergeTreeLogEntry&) @ 0x0000000015eba91b 20. /build/src/Storages/StorageReplicatedMergeTree.cpp:3876: bool std::__function::__policy_invoker&)>::__call_impl[abi:se190107])::$_1, bool (std::shared_ptr&)>>(std::__function::__policy_storage const*, std::shared_ptr&) @ 0x0000000015f9837e 21. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000165d6fc3 22. /build/src/Storages/StorageReplicatedMergeTree.cpp:3872: DB::StorageReplicatedMergeTree::processQueueEntry(std::shared_ptr) @ 0x0000000015efc18a 23. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001624c1b2 24. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000162f9c70 25. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x00000000162fa55a 26. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc6653 27. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000000fccc4c3 28. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc3d92 29. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fcca080 30. ? @ 0x00007fbc6213eac3 31. ? @ 0x00007fbc621d0850 (version 25.3.6.10636.altinitytest (altinity build)) 2025.07.28 11:55:52.483650 [ 5879 ] {2e20e405-2e85-42d7-a7e3-9406531a344f} executeQuery: Code: 57. DB::Exception: Table test_ttz886xs.prewhere_move already exists. (TABLE_ALREADY_EXISTS) (version 25.3.6.10636.altinitytest (altinity build)) (from [::1]:53506) (comment: 01582_move_to_prewhere_compact_parts.sql) (query 8, line 14) (in query: CREATE TABLE prewhere_move (x1 Int, x2 Int, x3 Int, x4 String CODEC(NONE)) ENGINE = MergeTree ORDER BY tuple();), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000a06a8eb 4. /build/src/Interpreters/InterpreterCreateQuery.cpp:1824: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x0000000014901d53 5. /build/src/Interpreters/InterpreterCreateQuery.cpp:1743: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000148f9aa9 6. /build/src/Interpreters/InterpreterCreateQuery.cpp:2352: DB::InterpreterCreateQuery::execute() @ 0x0000000014905a41 7. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88dc9 8. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 9. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 10. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 11. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 12. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 13. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 14. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 15. ? @ 0x00007fbc6213eac3 16. ? @ 0x00007fbc621d0850 2025.07.28 11:55:52.496551 [ 5879 ] {} TCPHandler: Code: 57. DB::Exception: Table test_ttz886xs.prewhere_move already exists. (TABLE_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000a06a8eb 4. /build/src/Interpreters/InterpreterCreateQuery.cpp:1824: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x0000000014901d53 5. /build/src/Interpreters/InterpreterCreateQuery.cpp:1743: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000148f9aa9 6. /build/src/Interpreters/InterpreterCreateQuery.cpp:2352: DB::InterpreterCreateQuery::execute() @ 0x0000000014905a41 7. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88dc9 8. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 9. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 10. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 11. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 12. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 13. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 14. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 15. ? @ 0x00007fbc6213eac3 16. ? @ 0x00007fbc621d0850 2025.07.28 11:55:52.497796 [ 3964 ] {} test_13.rmt2 (7f9b740d-015c-470e-8cc6-8ba33be0dc63): auto DB::StorageReplicatedMergeTree::processQueueEntry(ReplicatedMergeTreeQueue::SelectedEntryPtr)::(anonymous class)::operator()(LogEntryPtr &) const: Code: 86. DB::HTTPException: Received error from remote server http://146b4357c08d:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Ftest%2F01165%2Ftest_13%2Frmt%2Freplicas%2F1&part=20250728_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.6.10636.altinitytest (altinity build)) '. (RECEIVED_ERROR_FROM_REMOTE_IO_SERVER), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.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 const&, int&&, String const&, unsigned long&&, String const&) @ 0x000000000feda8d9 4. /build/src/IO/HTTPCommon.cpp:104: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x000000000feda6e2 5. /build/src/IO/HTTPCommon.cpp:93: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x000000000feda537 6. /build/src/IO/ReadWriteBufferFromHTTP.cpp:277: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x000000001184a4c4 7. /build/src/IO/ReadWriteBufferFromHTTP.cpp:285: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x000000001184a615 8. /build/src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x000000001184ae59 9. /build/src/IO/ReadWriteBufferFromHTTP.cpp:472: void std::__function::__policy_invoker::__call_impl[abi:se190107]>(std::__function::__policy_storage const*) @ 0x000000001184cedd 10. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001184858b 11. /build/src/IO/ReadWriteBufferFromHTTP.cpp:465: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x000000001184bf0b 12. /build/src/IO/ReadBuffer.h:60: DB::ReadBuffer::next() @ 0x000000000a148c7b 13. /build/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) @ 0x0000000011849fb2 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]>&)>&, 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&) @ 0x0000000011841980 15. /build/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) @ 0x000000001621208e 16. /build/src/Storages/StorageReplicatedMergeTree.cpp:5228: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl[abi:se190107] const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000015f9a5fe 17. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000015ed8bfd 18. /build/src/Storages/StorageReplicatedMergeTree.cpp:2514: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x0000000015ec9aab 19. /build/src/Storages/StorageReplicatedMergeTree.cpp:2349: DB::StorageReplicatedMergeTree::executeLogEntry(DB::ReplicatedMergeTreeLogEntry&) @ 0x0000000015eba91b 20. /build/src/Storages/StorageReplicatedMergeTree.cpp:3876: bool std::__function::__policy_invoker&)>::__call_impl[abi:se190107])::$_1, bool (std::shared_ptr&)>>(std::__function::__policy_storage const*, std::shared_ptr&) @ 0x0000000015f9837e 21. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000165d6fc3 22. /build/src/Storages/StorageReplicatedMergeTree.cpp:3872: DB::StorageReplicatedMergeTree::processQueueEntry(std::shared_ptr) @ 0x0000000015efc18a 23. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001624c1b2 24. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000162f9c70 25. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x00000000162fa55a 26. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc6653 27. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000000fccc4c3 28. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc3d92 29. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fcca080 30. ? @ 0x00007fbc6213eac3 31. ? @ 0x00007fbc621d0850 (version 25.3.6.10636.altinitytest (altinity build)) 2025.07.28 11:55:52.907215 [ 3965 ] {} test_13.rmt2 (7f9b740d-015c-470e-8cc6-8ba33be0dc63): auto DB::StorageReplicatedMergeTree::processQueueEntry(ReplicatedMergeTreeQueue::SelectedEntryPtr)::(anonymous class)::operator()(LogEntryPtr &) const: Code: 86. DB::HTTPException: Received error from remote server http://146b4357c08d:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Ftest%2F01165%2Ftest_13%2Frmt%2Freplicas%2F1&part=20250728_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.6.10636.altinitytest (altinity build)) '. (RECEIVED_ERROR_FROM_REMOTE_IO_SERVER), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.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 const&, int&&, String const&, unsigned long&&, String const&) @ 0x000000000feda8d9 4. /build/src/IO/HTTPCommon.cpp:104: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x000000000feda6e2 5. /build/src/IO/HTTPCommon.cpp:93: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x000000000feda537 6. /build/src/IO/ReadWriteBufferFromHTTP.cpp:277: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x000000001184a4c4 7. /build/src/IO/ReadWriteBufferFromHTTP.cpp:285: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x000000001184a615 8. /build/src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x000000001184ae59 9. /build/src/IO/ReadWriteBufferFromHTTP.cpp:472: void std::__function::__policy_invoker::__call_impl[abi:se190107]>(std::__function::__policy_storage const*) @ 0x000000001184cedd 10. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001184858b 11. /build/src/IO/ReadWriteBufferFromHTTP.cpp:465: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x000000001184bf0b 12. /build/src/IO/ReadBuffer.h:60: DB::ReadBuffer::next() @ 0x000000000a148c7b 13. /build/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) @ 0x0000000011849fb2 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]>&)>&, 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&) @ 0x0000000011841980 15. /build/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) @ 0x000000001621208e 16. /build/src/Storages/StorageReplicatedMergeTree.cpp:5228: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl[abi:se190107] const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000015f9a5fe 17. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000015ed8bfd 18. /build/src/Storages/StorageReplicatedMergeTree.cpp:2514: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x0000000015ec9aab 19. /build/src/Storages/StorageReplicatedMergeTree.cpp:2349: DB::StorageReplicatedMergeTree::executeLogEntry(DB::ReplicatedMergeTreeLogEntry&) @ 0x0000000015eba91b 20. /build/src/Storages/StorageReplicatedMergeTree.cpp:3876: bool std::__function::__policy_invoker&)>::__call_impl[abi:se190107])::$_1, bool (std::shared_ptr&)>>(std::__function::__policy_storage const*, std::shared_ptr&) @ 0x0000000015f9837e 21. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000165d6fc3 22. /build/src/Storages/StorageReplicatedMergeTree.cpp:3872: DB::StorageReplicatedMergeTree::processQueueEntry(std::shared_ptr) @ 0x0000000015efc18a 23. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001624c1b2 24. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000162f9c70 25. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x00000000162fa55a 26. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc6653 27. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000000fccc4c3 28. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc3d92 29. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fcca080 30. ? @ 0x00007fbc6213eac3 31. ? @ 0x00007fbc621d0850 (version 25.3.6.10636.altinitytest (altinity build)) 2025.07.28 11:55:53.886605 [ 3961 ] {} test_13.rmt2 (7f9b740d-015c-470e-8cc6-8ba33be0dc63): auto DB::StorageReplicatedMergeTree::processQueueEntry(ReplicatedMergeTreeQueue::SelectedEntryPtr)::(anonymous class)::operator()(LogEntryPtr &) const: Code: 86. DB::HTTPException: Received error from remote server http://146b4357c08d:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Ftest%2F01165%2Ftest_13%2Frmt%2Freplicas%2F1&part=20250728_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.6.10636.altinitytest (altinity build)) '. (RECEIVED_ERROR_FROM_REMOTE_IO_SERVER), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.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 const&, int&&, String const&, unsigned long&&, String const&) @ 0x000000000feda8d9 4. /build/src/IO/HTTPCommon.cpp:104: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x000000000feda6e2 5. /build/src/IO/HTTPCommon.cpp:93: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x000000000feda537 6. /build/src/IO/ReadWriteBufferFromHTTP.cpp:277: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x000000001184a4c4 7. /build/src/IO/ReadWriteBufferFromHTTP.cpp:285: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x000000001184a615 8. /build/src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x000000001184ae59 9. /build/src/IO/ReadWriteBufferFromHTTP.cpp:472: void std::__function::__policy_invoker::__call_impl[abi:se190107]>(std::__function::__policy_storage const*) @ 0x000000001184cedd 10. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001184858b 11. /build/src/IO/ReadWriteBufferFromHTTP.cpp:465: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x000000001184bf0b 12. /build/src/IO/ReadBuffer.h:60: DB::ReadBuffer::next() @ 0x000000000a148c7b 13. /build/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) @ 0x0000000011849fb2 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]>&)>&, 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&) @ 0x0000000011841980 15. /build/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) @ 0x000000001621208e 16. /build/src/Storages/StorageReplicatedMergeTree.cpp:5228: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl[abi:se190107] const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000015f9a5fe 17. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000015ed8bfd 18. /build/src/Storages/StorageReplicatedMergeTree.cpp:2514: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x0000000015ec9aab 19. /build/src/Storages/StorageReplicatedMergeTree.cpp:2349: DB::StorageReplicatedMergeTree::executeLogEntry(DB::ReplicatedMergeTreeLogEntry&) @ 0x0000000015eba91b 20. /build/src/Storages/StorageReplicatedMergeTree.cpp:3876: bool std::__function::__policy_invoker&)>::__call_impl[abi:se190107])::$_1, bool (std::shared_ptr&)>>(std::__function::__policy_storage const*, std::shared_ptr&) @ 0x0000000015f9837e 21. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000165d6fc3 22. /build/src/Storages/StorageReplicatedMergeTree.cpp:3872: DB::StorageReplicatedMergeTree::processQueueEntry(std::shared_ptr) @ 0x0000000015efc18a 23. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001624c1b2 24. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000162f9c70 25. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x00000000162fa55a 26. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc6653 27. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000000fccc4c3 28. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc3d92 29. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fcca080 30. ? @ 0x00007fbc6213eac3 31. ? @ 0x00007fbc621d0850 (version 25.3.6.10636.altinitytest (altinity build)) 2025.07.28 11:55:54.210209 [ 3974 ] {} test_13.rmt2 (7f9b740d-015c-470e-8cc6-8ba33be0dc63): auto DB::StorageReplicatedMergeTree::processQueueEntry(ReplicatedMergeTreeQueue::SelectedEntryPtr)::(anonymous class)::operator()(LogEntryPtr &) const: Code: 86. DB::HTTPException: Received error from remote server http://146b4357c08d:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Ftest%2F01165%2Ftest_13%2Frmt%2Freplicas%2F1&part=20250728_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.6.10636.altinitytest (altinity build)) '. (RECEIVED_ERROR_FROM_REMOTE_IO_SERVER), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.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 const&, int&&, String const&, unsigned long&&, String const&) @ 0x000000000feda8d9 4. /build/src/IO/HTTPCommon.cpp:104: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x000000000feda6e2 5. /build/src/IO/HTTPCommon.cpp:93: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x000000000feda537 6. /build/src/IO/ReadWriteBufferFromHTTP.cpp:277: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x000000001184a4c4 7. /build/src/IO/ReadWriteBufferFromHTTP.cpp:285: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x000000001184a615 8. /build/src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x000000001184ae59 9. /build/src/IO/ReadWriteBufferFromHTTP.cpp:472: void std::__function::__policy_invoker::__call_impl[abi:se190107]>(std::__function::__policy_storage const*) @ 0x000000001184cedd 10. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001184858b 11. /build/src/IO/ReadWriteBufferFromHTTP.cpp:465: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x000000001184bf0b 12. /build/src/IO/ReadBuffer.h:60: DB::ReadBuffer::next() @ 0x000000000a148c7b 13. /build/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) @ 0x0000000011849fb2 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]>&)>&, 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&) @ 0x0000000011841980 15. /build/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) @ 0x000000001621208e 16. /build/src/Storages/StorageReplicatedMergeTree.cpp:5228: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl[abi:se190107] const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000015f9a5fe 17. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000015ed8bfd 18. /build/src/Storages/StorageReplicatedMergeTree.cpp:2514: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x0000000015ec9aab 19. /build/src/Storages/StorageReplicatedMergeTree.cpp:2349: DB::StorageReplicatedMergeTree::executeLogEntry(DB::ReplicatedMergeTreeLogEntry&) @ 0x0000000015eba91b 20. /build/src/Storages/StorageReplicatedMergeTree.cpp:3876: bool std::__function::__policy_invoker&)>::__call_impl[abi:se190107])::$_1, bool (std::shared_ptr&)>>(std::__function::__policy_storage const*, std::shared_ptr&) @ 0x0000000015f9837e 21. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000165d6fc3 22. /build/src/Storages/StorageReplicatedMergeTree.cpp:3872: DB::StorageReplicatedMergeTree::processQueueEntry(std::shared_ptr) @ 0x0000000015efc18a 23. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001624c1b2 24. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000162f9c70 25. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x00000000162fa55a 26. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc6653 27. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000000fccc4c3 28. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc3d92 29. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fcca080 30. ? @ 0x00007fbc6213eac3 31. ? @ 0x00007fbc621d0850 (version 25.3.6.10636.altinitytest (altinity build)) 2025.07.28 11:55:54.367865 [ 17208 ] {76f48652-354b-4f77-817c-19573afc94b5} executeQuery: Code: 219. DB::Exception: New table appeared in database being dropped or detached. Try again. (DATABASE_NOT_EMPTY) (version 25.3.6.10636.altinitytest (altinity build)) (from [::1]:40280) (comment: 02803_backup_tmp_files.sh) (in query: DROP DATABASE IF EXISTS test_kfoe4gf2 SYNC ), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000000a074fcb 4. /build/src/Interpreters/DatabaseCatalog.cpp:608: DB::DatabaseCatalog::detachDatabase(std::shared_ptr, String const&, bool, bool) @ 0x00000000144f41b9 5. /build/src/Interpreters/InterpreterDropQuery.cpp:482: DB::InterpreterDropQuery::executeToDatabaseImpl(DB::ASTDropQuery const&, std::shared_ptr&, std::vector, DB::UUIDTag>, std::allocator, DB::UUIDTag>>>&) @ 0x00000000149179be 6. /build/src/Interpreters/InterpreterDropQuery.cpp:363: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x0000000014913988 7. /build/src/Interpreters/InterpreterDropQuery.cpp:99: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000014913142 8. /build/src/Interpreters/InterpreterDropQuery.cpp:72: DB::InterpreterDropQuery::execute() @ 0x0000000014912b65 9. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88dc9 10. /build/src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x0000000014c8ca7b 11. /build/src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000001686da12 12. /build/src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x0000000016870807 13. /build/src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x0000000016907e99 14. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 15. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 16. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 17. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 18. ? @ 0x00007fbc6213eac3 19. ? @ 0x00007fbc621d0850 2025.07.28 11:55:54.369529 [ 17208 ] {76f48652-354b-4f77-817c-19573afc94b5} 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. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000000a074fcb 4. /build/src/Interpreters/DatabaseCatalog.cpp:608: DB::DatabaseCatalog::detachDatabase(std::shared_ptr, String const&, bool, bool) @ 0x00000000144f41b9 5. /build/src/Interpreters/InterpreterDropQuery.cpp:482: DB::InterpreterDropQuery::executeToDatabaseImpl(DB::ASTDropQuery const&, std::shared_ptr&, std::vector, DB::UUIDTag>, std::allocator, DB::UUIDTag>>>&) @ 0x00000000149179be 6. /build/src/Interpreters/InterpreterDropQuery.cpp:363: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x0000000014913988 7. /build/src/Interpreters/InterpreterDropQuery.cpp:99: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000014913142 8. /build/src/Interpreters/InterpreterDropQuery.cpp:72: DB::InterpreterDropQuery::execute() @ 0x0000000014912b65 9. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88dc9 10. /build/src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x0000000014c8ca7b 11. /build/src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000001686da12 12. /build/src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x0000000016870807 13. /build/src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x0000000016907e99 14. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 15. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 16. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 17. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 18. ? @ 0x00007fbc6213eac3 19. ? @ 0x00007fbc621d0850 (version 25.3.6.10636.altinitytest (altinity build)) 2025.07.28 11:55:54.630723 [ 17255 ] {cf4eb8f0-dcca-4d1a-b77b-a1bfec7ac44c} executeQuery: Code: 407. DB::Exception: Numeric overflow: In scope SELECT ignore(addHours(now64(3), inf)) FROM numbers(2). (DECIMAL_OVERFLOW) (version 25.3.6.10636.altinitytest (altinity build)) (from [::1]:53604) (comment: 01773_datetime64_add_ubsan.sql) (query 1, line 1) (in query: -- The result is unspecified but UBSan should not argue. SELECT ignore(addHours(now64(3), inf)) FROM numbers(2);), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000000a074fcb 4. /build/src/Functions/FunctionDateOrDateTimeAddInterval.h:486: long DB::Processor::checkOverflow(double) @ 0x000000000a9fb324 5. /build/src/Functions/FunctionDateOrDateTimeAddInterval.h:515: void DB::Processor::vectorVector, DB::ColumnDecimal, DB::ColumnVector>(DB::ColumnDecimal const&, DB::ColumnDecimal&, DB::ColumnVector const&, DateLUTImpl const&, unsigned short, unsigned long) const @ 0x000000000aa04238 6. /build/src/Functions/FunctionDateOrDateTimeAddInterval.h:466: void DB::Processor::vectorVector, DB::ColumnDecimal>(DB::ColumnDecimal const&, DB::ColumnDecimal&, DB::IColumn const&, DateLUTImpl const&, unsigned short, unsigned long) const @ 0x000000000aa02a62 7. /build/src/Functions/FunctionDateOrDateTimeAddInterval.h:559: DB::DateTimeAddIntervalImpl::execute(DB::AddHoursImpl, std::vector> const&, std::shared_ptr const&, unsigned short, unsigned long) @ 0x000000000a9f8d91 8. /build/src/Functions/FunctionDateOrDateTimeAddInterval.h:721: DB::FunctionDateOrDateTimeAddInterval::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000a9f767a 9. /build/src/Functions/IFunction.h:437: DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000a069f2a 10. /build/src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000012d9965a 11. /build/src/Functions/IFunction.cpp:351: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d93b02 12. /build/src/Functions/IFunction.cpp:177: DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d93698 13. /build/src/Functions/IFunction.cpp:343: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d93aad 14. /build/src/Functions/IFunction.cpp:420: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d95059 15. /build/src/Functions/IFunction.cpp:498: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d95c72 16. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3567: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000014034494 17. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3838: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000014019a9e 18. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3980: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000014018e31 19. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:2925: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000001402fcbd 20. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3838: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000014019a9e 21. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3980: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000014018e31 22. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:4304: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000014042fa7 23. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5605: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000014013749 24. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000140127f9 25. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000014011fce 26. /build/src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000001406ce8a 27. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000014973b42 28. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000001497268d 29. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000014974d24 30. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001492924b 31. /build/src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88641 2025.07.28 11:55:54.634531 [ 17255 ] {} TCPHandler: Code: 407. DB::Exception: Numeric overflow: In scope SELECT ignore(addHours(now64(3), inf)) FROM numbers(2). (DECIMAL_OVERFLOW), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000000a074fcb 4. /build/src/Functions/FunctionDateOrDateTimeAddInterval.h:486: long DB::Processor::checkOverflow(double) @ 0x000000000a9fb324 5. /build/src/Functions/FunctionDateOrDateTimeAddInterval.h:515: void DB::Processor::vectorVector, DB::ColumnDecimal, DB::ColumnVector>(DB::ColumnDecimal const&, DB::ColumnDecimal&, DB::ColumnVector const&, DateLUTImpl const&, unsigned short, unsigned long) const @ 0x000000000aa04238 6. /build/src/Functions/FunctionDateOrDateTimeAddInterval.h:466: void DB::Processor::vectorVector, DB::ColumnDecimal>(DB::ColumnDecimal const&, DB::ColumnDecimal&, DB::IColumn const&, DateLUTImpl const&, unsigned short, unsigned long) const @ 0x000000000aa02a62 7. /build/src/Functions/FunctionDateOrDateTimeAddInterval.h:559: DB::DateTimeAddIntervalImpl::execute(DB::AddHoursImpl, std::vector> const&, std::shared_ptr const&, unsigned short, unsigned long) @ 0x000000000a9f8d91 8. /build/src/Functions/FunctionDateOrDateTimeAddInterval.h:721: DB::FunctionDateOrDateTimeAddInterval::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000a9f767a 9. /build/src/Functions/IFunction.h:437: DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000a069f2a 10. /build/src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000012d9965a 11. /build/src/Functions/IFunction.cpp:351: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d93b02 12. /build/src/Functions/IFunction.cpp:177: DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d93698 13. /build/src/Functions/IFunction.cpp:343: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d93aad 14. /build/src/Functions/IFunction.cpp:420: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d95059 15. /build/src/Functions/IFunction.cpp:498: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d95c72 16. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3567: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000014034494 17. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3838: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000014019a9e 18. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3980: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000014018e31 19. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:2925: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000001402fcbd 20. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3838: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000014019a9e 21. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3980: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000014018e31 22. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:4304: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000014042fa7 23. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5605: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000014013749 24. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000140127f9 25. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000014011fce 26. /build/src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000001406ce8a 27. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000014973b42 28. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000001497268d 29. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000014974d24 30. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001492924b 31. /build/src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88641 2025.07.28 11:55:55.064551 [ 3963 ] {} test_13.rmt2 (7f9b740d-015c-470e-8cc6-8ba33be0dc63): auto DB::StorageReplicatedMergeTree::processQueueEntry(ReplicatedMergeTreeQueue::SelectedEntryPtr)::(anonymous class)::operator()(LogEntryPtr &) const: Code: 86. DB::HTTPException: Received error from remote server http://146b4357c08d:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Ftest%2F01165%2Ftest_13%2Frmt%2Freplicas%2F1&part=20250728_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.6.10636.altinitytest (altinity build)) '. (RECEIVED_ERROR_FROM_REMOTE_IO_SERVER), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.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 const&, int&&, String const&, unsigned long&&, String const&) @ 0x000000000feda8d9 4. /build/src/IO/HTTPCommon.cpp:104: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x000000000feda6e2 5. /build/src/IO/HTTPCommon.cpp:93: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x000000000feda537 6. /build/src/IO/ReadWriteBufferFromHTTP.cpp:277: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x000000001184a4c4 7. /build/src/IO/ReadWriteBufferFromHTTP.cpp:285: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x000000001184a615 8. /build/src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x000000001184ae59 9. /build/src/IO/ReadWriteBufferFromHTTP.cpp:472: void std::__function::__policy_invoker::__call_impl[abi:se190107]>(std::__function::__policy_storage const*) @ 0x000000001184cedd 10. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001184858b 11. /build/src/IO/ReadWriteBufferFromHTTP.cpp:465: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x000000001184bf0b 12. /build/src/IO/ReadBuffer.h:60: DB::ReadBuffer::next() @ 0x000000000a148c7b 13. /build/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) @ 0x0000000011849fb2 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]>&)>&, 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&) @ 0x0000000011841980 15. /build/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) @ 0x000000001621208e 16. /build/src/Storages/StorageReplicatedMergeTree.cpp:5228: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl[abi:se190107] const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000015f9a5fe 17. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000015ed8bfd 18. /build/src/Storages/StorageReplicatedMergeTree.cpp:2514: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x0000000015ec9aab 19. /build/src/Storages/StorageReplicatedMergeTree.cpp:2349: DB::StorageReplicatedMergeTree::executeLogEntry(DB::ReplicatedMergeTreeLogEntry&) @ 0x0000000015eba91b 20. /build/src/Storages/StorageReplicatedMergeTree.cpp:3876: bool std::__function::__policy_invoker&)>::__call_impl[abi:se190107])::$_1, bool (std::shared_ptr&)>>(std::__function::__policy_storage const*, std::shared_ptr&) @ 0x0000000015f9837e 21. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000165d6fc3 22. /build/src/Storages/StorageReplicatedMergeTree.cpp:3872: DB::StorageReplicatedMergeTree::processQueueEntry(std::shared_ptr) @ 0x0000000015efc18a 23. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001624c1b2 24. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000162f9c70 25. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x00000000162fa55a 26. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc6653 27. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000000fccc4c3 28. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc3d92 29. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fcca080 30. ? @ 0x00007fbc6213eac3 31. ? @ 0x00007fbc621d0850 (version 25.3.6.10636.altinitytest (altinity build)) 2025.07.28 11:55:55.645014 [ 7630 ] {ed0ecb6e-738a-4d57-89d1-0b459e267576} executeQuery: Code: 36. DB::Exception: Invalid time zone: Ðбырвалг. (BAD_ARGUMENTS) (version 25.3.6.10636.altinitytest (altinity build)) (from [::1]:53646) (comment: 02737_session_timezone.sql) (query 1, line 1) (in query: SET session_timezone = 'Ðбырвалг';), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000a9b78ab 4. /build/src/Core/SettingsFields.cpp:519: DB::SettingFieldTimezone::validateTimezone(String const&) @ 0x0000000013b8c423 5. /build/src/Core/SettingsFields.h:507: DB::SettingFieldTimezone::SettingFieldTimezone(DB::Field const&) @ 0x0000000013b10027 6. /build/src/Core/Settings.cpp:6219: DB::SettingsTraits::Accessor::instance()::$_0::operator()() const::'lambda1657'(DB::Field const&)::__invoke(DB::Field const&) @ 0x0000000013acc297 7. /build/src/Core/Settings.cpp:6218: DB::BaseSettings::castValueUtil(std::basic_string_view>, DB::Field const&) @ 0x0000000013b07122 8. /build/src/Core/Settings.cpp:6661: DB::Settings::castValueUtil(std::basic_string_view>, DB::Field const&) @ 0x0000000013a58cc9 9. /build/src/Access/SettingsConstraints.cpp:245: bool DB::getNewValueToCheck(DB::Settings const&, DB::SettingChange&, DB::Field&, bool) @ 0x000000001385a1ab 10. /build/src/Access/SettingsConstraints.cpp:297: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000013858f7b 11. /build/src/Access/SettingsConstraints.cpp:194: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges const&, DB::SettingSource) const @ 0x00000000138591b3 12. /build/src/Interpreters/Context.cpp:2722: DB::Context::checkSettingsConstraints(DB::SettingsChanges const&, DB::SettingSource) @ 0x0000000014436509 13. /build/src/Interpreters/InterpreterSetQuery.cpp:28: DB::InterpreterSetQuery::execute() @ 0x00000000149e240a 14. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88dc9 15. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 16. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 17. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 18. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 19. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 20. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 21. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 22. ? @ 0x00007fbc6213eac3 23. ? @ 0x00007fbc621d0850 2025.07.28 11:55:55.659602 [ 7630 ] {} TCPHandler: Code: 36. DB::Exception: Invalid time zone: Ðбырвалг. (BAD_ARGUMENTS), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000a9b78ab 4. /build/src/Core/SettingsFields.cpp:519: DB::SettingFieldTimezone::validateTimezone(String const&) @ 0x0000000013b8c423 5. /build/src/Core/SettingsFields.h:507: DB::SettingFieldTimezone::SettingFieldTimezone(DB::Field const&) @ 0x0000000013b10027 6. /build/src/Core/Settings.cpp:6219: DB::SettingsTraits::Accessor::instance()::$_0::operator()() const::'lambda1657'(DB::Field const&)::__invoke(DB::Field const&) @ 0x0000000013acc297 7. /build/src/Core/Settings.cpp:6218: DB::BaseSettings::castValueUtil(std::basic_string_view>, DB::Field const&) @ 0x0000000013b07122 8. /build/src/Core/Settings.cpp:6661: DB::Settings::castValueUtil(std::basic_string_view>, DB::Field const&) @ 0x0000000013a58cc9 9. /build/src/Access/SettingsConstraints.cpp:245: bool DB::getNewValueToCheck(DB::Settings const&, DB::SettingChange&, DB::Field&, bool) @ 0x000000001385a1ab 10. /build/src/Access/SettingsConstraints.cpp:297: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000013858f7b 11. /build/src/Access/SettingsConstraints.cpp:194: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges const&, DB::SettingSource) const @ 0x00000000138591b3 12. /build/src/Interpreters/Context.cpp:2722: DB::Context::checkSettingsConstraints(DB::SettingsChanges const&, DB::SettingSource) @ 0x0000000014436509 13. /build/src/Interpreters/InterpreterSetQuery.cpp:28: DB::InterpreterSetQuery::execute() @ 0x00000000149e240a 14. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88dc9 15. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 16. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 17. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 18. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 19. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 20. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 21. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 22. ? @ 0x00007fbc6213eac3 23. ? @ 0x00007fbc621d0850 2025.07.28 11:55:55.729891 [ 3960 ] {} test_13.rmt2 (7f9b740d-015c-470e-8cc6-8ba33be0dc63): auto DB::StorageReplicatedMergeTree::processQueueEntry(ReplicatedMergeTreeQueue::SelectedEntryPtr)::(anonymous class)::operator()(LogEntryPtr &) const: Code: 86. DB::HTTPException: Received error from remote server http://146b4357c08d:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Ftest%2F01165%2Ftest_13%2Frmt%2Freplicas%2F1&part=20250728_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.6.10636.altinitytest (altinity build)) '. (RECEIVED_ERROR_FROM_REMOTE_IO_SERVER), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.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 const&, int&&, String const&, unsigned long&&, String const&) @ 0x000000000feda8d9 4. /build/src/IO/HTTPCommon.cpp:104: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x000000000feda6e2 5. /build/src/IO/HTTPCommon.cpp:93: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x000000000feda537 6. /build/src/IO/ReadWriteBufferFromHTTP.cpp:277: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x000000001184a4c4 7. /build/src/IO/ReadWriteBufferFromHTTP.cpp:285: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x000000001184a615 8. /build/src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x000000001184ae59 9. /build/src/IO/ReadWriteBufferFromHTTP.cpp:472: void std::__function::__policy_invoker::__call_impl[abi:se190107]>(std::__function::__policy_storage const*) @ 0x000000001184cedd 10. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001184858b 11. /build/src/IO/ReadWriteBufferFromHTTP.cpp:465: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x000000001184bf0b 12. /build/src/IO/ReadBuffer.h:60: DB::ReadBuffer::next() @ 0x000000000a148c7b 13. /build/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) @ 0x0000000011849fb2 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]>&)>&, 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&) @ 0x0000000011841980 15. /build/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) @ 0x000000001621208e 16. /build/src/Storages/StorageReplicatedMergeTree.cpp:5228: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl[abi:se190107] const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000015f9a5fe 17. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000015ed8bfd 18. /build/src/Storages/StorageReplicatedMergeTree.cpp:2514: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x0000000015ec9aab 19. /build/src/Storages/StorageReplicatedMergeTree.cpp:2349: DB::StorageReplicatedMergeTree::executeLogEntry(DB::ReplicatedMergeTreeLogEntry&) @ 0x0000000015eba91b 20. /build/src/Storages/StorageReplicatedMergeTree.cpp:3876: bool std::__function::__policy_invoker&)>::__call_impl[abi:se190107])::$_1, bool (std::shared_ptr&)>>(std::__function::__policy_storage const*, std::shared_ptr&) @ 0x0000000015f9837e 21. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000165d6fc3 22. /build/src/Storages/StorageReplicatedMergeTree.cpp:3872: DB::StorageReplicatedMergeTree::processQueueEntry(std::shared_ptr) @ 0x0000000015efc18a 23. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001624c1b2 24. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000162f9c70 25. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x00000000162fa55a 26. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc6653 27. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000000fccc4c3 28. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc3d92 29. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fcca080 30. ? @ 0x00007fbc6213eac3 31. ? @ 0x00007fbc621d0850 (version 25.3.6.10636.altinitytest (altinity build)) 2025.07.28 11:55:56.492834 [ 3976 ] {} test_13.rmt2 (7f9b740d-015c-470e-8cc6-8ba33be0dc63): auto DB::StorageReplicatedMergeTree::processQueueEntry(ReplicatedMergeTreeQueue::SelectedEntryPtr)::(anonymous class)::operator()(LogEntryPtr &) const: Code: 86. DB::HTTPException: Received error from remote server http://146b4357c08d:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Ftest%2F01165%2Ftest_13%2Frmt%2Freplicas%2F1&part=20250728_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.6.10636.altinitytest (altinity build)) '. (RECEIVED_ERROR_FROM_REMOTE_IO_SERVER), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.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 const&, int&&, String const&, unsigned long&&, String const&) @ 0x000000000feda8d9 4. /build/src/IO/HTTPCommon.cpp:104: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x000000000feda6e2 5. /build/src/IO/HTTPCommon.cpp:93: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x000000000feda537 6. /build/src/IO/ReadWriteBufferFromHTTP.cpp:277: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x000000001184a4c4 7. /build/src/IO/ReadWriteBufferFromHTTP.cpp:285: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x000000001184a615 8. /build/src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x000000001184ae59 9. /build/src/IO/ReadWriteBufferFromHTTP.cpp:472: void std::__function::__policy_invoker::__call_impl[abi:se190107]>(std::__function::__policy_storage const*) @ 0x000000001184cedd 10. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001184858b 11. /build/src/IO/ReadWriteBufferFromHTTP.cpp:465: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x000000001184bf0b 12. /build/src/IO/ReadBuffer.h:60: DB::ReadBuffer::next() @ 0x000000000a148c7b 13. /build/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) @ 0x0000000011849fb2 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]>&)>&, 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&) @ 0x0000000011841980 15. /build/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) @ 0x000000001621208e 16. /build/src/Storages/StorageReplicatedMergeTree.cpp:5228: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl[abi:se190107] const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000015f9a5fe 17. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000015ed8bfd 18. /build/src/Storages/StorageReplicatedMergeTree.cpp:2514: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x0000000015ec9aab 19. /build/src/Storages/StorageReplicatedMergeTree.cpp:2349: DB::StorageReplicatedMergeTree::executeLogEntry(DB::ReplicatedMergeTreeLogEntry&) @ 0x0000000015eba91b 20. /build/src/Storages/StorageReplicatedMergeTree.cpp:3876: bool std::__function::__policy_invoker&)>::__call_impl[abi:se190107])::$_1, bool (std::shared_ptr&)>>(std::__function::__policy_storage const*, std::shared_ptr&) @ 0x0000000015f9837e 21. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000165d6fc3 22. /build/src/Storages/StorageReplicatedMergeTree.cpp:3872: DB::StorageReplicatedMergeTree::processQueueEntry(std::shared_ptr) @ 0x0000000015efc18a 23. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001624c1b2 24. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000162f9c70 25. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x00000000162fa55a 26. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc6653 27. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000000fccc4c3 28. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc3d92 29. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fcca080 30. ? @ 0x00007fbc6213eac3 31. ? @ 0x00007fbc621d0850 (version 25.3.6.10636.altinitytest (altinity build)) 2025.07.28 11:55:57.104451 [ 3970 ] {} test_13.rmt2 (7f9b740d-015c-470e-8cc6-8ba33be0dc63): auto DB::StorageReplicatedMergeTree::processQueueEntry(ReplicatedMergeTreeQueue::SelectedEntryPtr)::(anonymous class)::operator()(LogEntryPtr &) const: Code: 86. DB::HTTPException: Received error from remote server http://146b4357c08d:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Ftest%2F01165%2Ftest_13%2Frmt%2Freplicas%2F1&part=20250728_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.6.10636.altinitytest (altinity build)) '. (RECEIVED_ERROR_FROM_REMOTE_IO_SERVER), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.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 const&, int&&, String const&, unsigned long&&, String const&) @ 0x000000000feda8d9 4. /build/src/IO/HTTPCommon.cpp:104: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x000000000feda6e2 5. /build/src/IO/HTTPCommon.cpp:93: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x000000000feda537 6. /build/src/IO/ReadWriteBufferFromHTTP.cpp:277: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x000000001184a4c4 7. /build/src/IO/ReadWriteBufferFromHTTP.cpp:285: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x000000001184a615 8. /build/src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x000000001184ae59 9. /build/src/IO/ReadWriteBufferFromHTTP.cpp:472: void std::__function::__policy_invoker::__call_impl[abi:se190107]>(std::__function::__policy_storage const*) @ 0x000000001184cedd 10. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001184858b 11. /build/src/IO/ReadWriteBufferFromHTTP.cpp:465: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x000000001184bf0b 12. /build/src/IO/ReadBuffer.h:60: DB::ReadBuffer::next() @ 0x000000000a148c7b 13. /build/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) @ 0x0000000011849fb2 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]>&)>&, 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&) @ 0x0000000011841980 15. /build/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) @ 0x000000001621208e 16. /build/src/Storages/StorageReplicatedMergeTree.cpp:5228: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl[abi:se190107] const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000015f9a5fe 17. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000015ed8bfd 18. /build/src/Storages/StorageReplicatedMergeTree.cpp:2514: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x0000000015ec9aab 19. /build/src/Storages/StorageReplicatedMergeTree.cpp:2349: DB::StorageReplicatedMergeTree::executeLogEntry(DB::ReplicatedMergeTreeLogEntry&) @ 0x0000000015eba91b 20. /build/src/Storages/StorageReplicatedMergeTree.cpp:3876: bool std::__function::__policy_invoker&)>::__call_impl[abi:se190107])::$_1, bool (std::shared_ptr&)>>(std::__function::__policy_storage const*, std::shared_ptr&) @ 0x0000000015f9837e 21. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000165d6fc3 22. /build/src/Storages/StorageReplicatedMergeTree.cpp:3872: DB::StorageReplicatedMergeTree::processQueueEntry(std::shared_ptr) @ 0x0000000015efc18a 23. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001624c1b2 24. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000162f9c70 25. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x00000000162fa55a 26. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc6653 27. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000000fccc4c3 28. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc3d92 29. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fcca080 30. ? @ 0x00007fbc6213eac3 31. ? @ 0x00007fbc621d0850 (version 25.3.6.10636.altinitytest (altinity build)) 2025.07.28 11:55:57.614045 [ 3964 ] {} test_13.rmt2 (7f9b740d-015c-470e-8cc6-8ba33be0dc63): auto DB::StorageReplicatedMergeTree::processQueueEntry(ReplicatedMergeTreeQueue::SelectedEntryPtr)::(anonymous class)::operator()(LogEntryPtr &) const: Code: 86. DB::HTTPException: Received error from remote server http://146b4357c08d:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Ftest%2F01165%2Ftest_13%2Frmt%2Freplicas%2F1&part=20250728_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.6.10636.altinitytest (altinity build)) '. (RECEIVED_ERROR_FROM_REMOTE_IO_SERVER), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.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 const&, int&&, String const&, unsigned long&&, String const&) @ 0x000000000feda8d9 4. /build/src/IO/HTTPCommon.cpp:104: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x000000000feda6e2 5. /build/src/IO/HTTPCommon.cpp:93: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x000000000feda537 6. /build/src/IO/ReadWriteBufferFromHTTP.cpp:277: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x000000001184a4c4 7. /build/src/IO/ReadWriteBufferFromHTTP.cpp:285: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x000000001184a615 8. /build/src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x000000001184ae59 9. /build/src/IO/ReadWriteBufferFromHTTP.cpp:472: void std::__function::__policy_invoker::__call_impl[abi:se190107]>(std::__function::__policy_storage const*) @ 0x000000001184cedd 10. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001184858b 11. /build/src/IO/ReadWriteBufferFromHTTP.cpp:465: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x000000001184bf0b 12. /build/src/IO/ReadBuffer.h:60: DB::ReadBuffer::next() @ 0x000000000a148c7b 13. /build/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) @ 0x0000000011849fb2 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]>&)>&, 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&) @ 0x0000000011841980 15. /build/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) @ 0x000000001621208e 16. /build/src/Storages/StorageReplicatedMergeTree.cpp:5228: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl[abi:se190107] const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000015f9a5fe 17. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000015ed8bfd 18. /build/src/Storages/StorageReplicatedMergeTree.cpp:2514: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x0000000015ec9aab 19. /build/src/Storages/StorageReplicatedMergeTree.cpp:2349: DB::StorageReplicatedMergeTree::executeLogEntry(DB::ReplicatedMergeTreeLogEntry&) @ 0x0000000015eba91b 20. /build/src/Storages/StorageReplicatedMergeTree.cpp:3876: bool std::__function::__policy_invoker&)>::__call_impl[abi:se190107])::$_1, bool (std::shared_ptr&)>>(std::__function::__policy_storage const*, std::shared_ptr&) @ 0x0000000015f9837e 21. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000165d6fc3 22. /build/src/Storages/StorageReplicatedMergeTree.cpp:3872: DB::StorageReplicatedMergeTree::processQueueEntry(std::shared_ptr) @ 0x0000000015efc18a 23. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001624c1b2 24. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000162f9c70 25. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x00000000162fa55a 26. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc6653 27. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000000fccc4c3 28. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc3d92 29. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fcca080 30. ? @ 0x00007fbc6213eac3 31. ? @ 0x00007fbc621d0850 (version 25.3.6.10636.altinitytest (altinity build)) 2025.07.28 11:55:57.867772 [ 3965 ] {} test_13.rmt2 (7f9b740d-015c-470e-8cc6-8ba33be0dc63): auto DB::StorageReplicatedMergeTree::processQueueEntry(ReplicatedMergeTreeQueue::SelectedEntryPtr)::(anonymous class)::operator()(LogEntryPtr &) const: Code: 86. DB::HTTPException: Received error from remote server http://146b4357c08d:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Ftest%2F01165%2Ftest_13%2Frmt%2Freplicas%2F1&part=20250728_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.6.10636.altinitytest (altinity build)) '. (RECEIVED_ERROR_FROM_REMOTE_IO_SERVER), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.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 const&, int&&, String const&, unsigned long&&, String const&) @ 0x000000000feda8d9 4. /build/src/IO/HTTPCommon.cpp:104: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x000000000feda6e2 5. /build/src/IO/HTTPCommon.cpp:93: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x000000000feda537 6. /build/src/IO/ReadWriteBufferFromHTTP.cpp:277: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x000000001184a4c4 7. /build/src/IO/ReadWriteBufferFromHTTP.cpp:285: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x000000001184a615 8. /build/src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x000000001184ae59 9. /build/src/IO/ReadWriteBufferFromHTTP.cpp:472: void std::__function::__policy_invoker::__call_impl[abi:se190107]>(std::__function::__policy_storage const*) @ 0x000000001184cedd 10. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001184858b 11. /build/src/IO/ReadWriteBufferFromHTTP.cpp:465: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x000000001184bf0b 12. /build/src/IO/ReadBuffer.h:60: DB::ReadBuffer::next() @ 0x000000000a148c7b 13. /build/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) @ 0x0000000011849fb2 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]>&)>&, 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&) @ 0x0000000011841980 15. /build/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) @ 0x000000001621208e 16. /build/src/Storages/StorageReplicatedMergeTree.cpp:5228: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl[abi:se190107] const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000015f9a5fe 17. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000015ed8bfd 18. /build/src/Storages/StorageReplicatedMergeTree.cpp:2514: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x0000000015ec9aab 19. /build/src/Storages/StorageReplicatedMergeTree.cpp:2349: DB::StorageReplicatedMergeTree::executeLogEntry(DB::ReplicatedMergeTreeLogEntry&) @ 0x0000000015eba91b 20. /build/src/Storages/StorageReplicatedMergeTree.cpp:3876: bool std::__function::__policy_invoker&)>::__call_impl[abi:se190107])::$_1, bool (std::shared_ptr&)>>(std::__function::__policy_storage const*, std::shared_ptr&) @ 0x0000000015f9837e 21. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000165d6fc3 22. /build/src/Storages/StorageReplicatedMergeTree.cpp:3872: DB::StorageReplicatedMergeTree::processQueueEntry(std::shared_ptr) @ 0x0000000015efc18a 23. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001624c1b2 24. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000162f9c70 25. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x00000000162fa55a 26. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc6653 27. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000000fccc4c3 28. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc3d92 29. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fcca080 30. ? @ 0x00007fbc6213eac3 31. ? @ 0x00007fbc621d0850 (version 25.3.6.10636.altinitytest (altinity build)) 2025.07.28 11:55:58.652780 [ 3971 ] {} test_13.rmt2 (7f9b740d-015c-470e-8cc6-8ba33be0dc63): auto DB::StorageReplicatedMergeTree::processQueueEntry(ReplicatedMergeTreeQueue::SelectedEntryPtr)::(anonymous class)::operator()(LogEntryPtr &) const: Code: 86. DB::HTTPException: Received error from remote server http://146b4357c08d:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Ftest%2F01165%2Ftest_13%2Frmt%2Freplicas%2F1&part=20250728_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.6.10636.altinitytest (altinity build)) '. (RECEIVED_ERROR_FROM_REMOTE_IO_SERVER), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.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 const&, int&&, String const&, unsigned long&&, String const&) @ 0x000000000feda8d9 4. /build/src/IO/HTTPCommon.cpp:104: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x000000000feda6e2 5. /build/src/IO/HTTPCommon.cpp:93: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x000000000feda537 6. /build/src/IO/ReadWriteBufferFromHTTP.cpp:277: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x000000001184a4c4 7. /build/src/IO/ReadWriteBufferFromHTTP.cpp:285: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x000000001184a615 8. /build/src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x000000001184ae59 9. /build/src/IO/ReadWriteBufferFromHTTP.cpp:472: void std::__function::__policy_invoker::__call_impl[abi:se190107]>(std::__function::__policy_storage const*) @ 0x000000001184cedd 10. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001184858b 11. /build/src/IO/ReadWriteBufferFromHTTP.cpp:465: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x000000001184bf0b 12. /build/src/IO/ReadBuffer.h:60: DB::ReadBuffer::next() @ 0x000000000a148c7b 13. /build/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) @ 0x0000000011849fb2 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]>&)>&, 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&) @ 0x0000000011841980 15. /build/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) @ 0x000000001621208e 16. /build/src/Storages/StorageReplicatedMergeTree.cpp:5228: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl[abi:se190107] const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000015f9a5fe 17. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000015ed8bfd 18. /build/src/Storages/StorageReplicatedMergeTree.cpp:2514: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x0000000015ec9aab 19. /build/src/Storages/StorageReplicatedMergeTree.cpp:2349: DB::StorageReplicatedMergeTree::executeLogEntry(DB::ReplicatedMergeTreeLogEntry&) @ 0x0000000015eba91b 20. /build/src/Storages/StorageReplicatedMergeTree.cpp:3876: bool std::__function::__policy_invoker&)>::__call_impl[abi:se190107])::$_1, bool (std::shared_ptr&)>>(std::__function::__policy_storage const*, std::shared_ptr&) @ 0x0000000015f9837e 21. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000165d6fc3 22. /build/src/Storages/StorageReplicatedMergeTree.cpp:3872: DB::StorageReplicatedMergeTree::processQueueEntry(std::shared_ptr) @ 0x0000000015efc18a 23. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001624c1b2 24. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000162f9c70 25. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x00000000162fa55a 26. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc6653 27. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000000fccc4c3 28. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc3d92 29. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fcca080 30. ? @ 0x00007fbc6213eac3 31. ? @ 0x00007fbc621d0850 (version 25.3.6.10636.altinitytest (altinity build)) 2025.07.28 11:55:59.404133 [ 3972 ] {} test_13.rmt2 (7f9b740d-015c-470e-8cc6-8ba33be0dc63): auto DB::StorageReplicatedMergeTree::processQueueEntry(ReplicatedMergeTreeQueue::SelectedEntryPtr)::(anonymous class)::operator()(LogEntryPtr &) const: Code: 86. DB::HTTPException: Received error from remote server http://146b4357c08d:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Ftest%2F01165%2Ftest_13%2Frmt%2Freplicas%2F1&part=20250728_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.6.10636.altinitytest (altinity build)) '. (RECEIVED_ERROR_FROM_REMOTE_IO_SERVER), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.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 const&, int&&, String const&, unsigned long&&, String const&) @ 0x000000000feda8d9 4. /build/src/IO/HTTPCommon.cpp:104: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x000000000feda6e2 5. /build/src/IO/HTTPCommon.cpp:93: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x000000000feda537 6. /build/src/IO/ReadWriteBufferFromHTTP.cpp:277: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x000000001184a4c4 7. /build/src/IO/ReadWriteBufferFromHTTP.cpp:285: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x000000001184a615 8. /build/src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x000000001184ae59 9. /build/src/IO/ReadWriteBufferFromHTTP.cpp:472: void std::__function::__policy_invoker::__call_impl[abi:se190107]>(std::__function::__policy_storage const*) @ 0x000000001184cedd 10. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001184858b 11. /build/src/IO/ReadWriteBufferFromHTTP.cpp:465: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x000000001184bf0b 12. /build/src/IO/ReadBuffer.h:60: DB::ReadBuffer::next() @ 0x000000000a148c7b 13. /build/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) @ 0x0000000011849fb2 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]>&)>&, 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&) @ 0x0000000011841980 15. /build/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) @ 0x000000001621208e 16. /build/src/Storages/StorageReplicatedMergeTree.cpp:5228: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl[abi:se190107] const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000015f9a5fe 17. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000015ed8bfd 18. /build/src/Storages/StorageReplicatedMergeTree.cpp:2514: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x0000000015ec9aab 19. /build/src/Storages/StorageReplicatedMergeTree.cpp:2349: DB::StorageReplicatedMergeTree::executeLogEntry(DB::ReplicatedMergeTreeLogEntry&) @ 0x0000000015eba91b 20. /build/src/Storages/StorageReplicatedMergeTree.cpp:3876: bool std::__function::__policy_invoker&)>::__call_impl[abi:se190107])::$_1, bool (std::shared_ptr&)>>(std::__function::__policy_storage const*, std::shared_ptr&) @ 0x0000000015f9837e 21. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000165d6fc3 22. /build/src/Storages/StorageReplicatedMergeTree.cpp:3872: DB::StorageReplicatedMergeTree::processQueueEntry(std::shared_ptr) @ 0x0000000015efc18a 23. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001624c1b2 24. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000162f9c70 25. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x00000000162fa55a 26. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc6653 27. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000000fccc4c3 28. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc3d92 29. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fcca080 30. ? @ 0x00007fbc6213eac3 31. ? @ 0x00007fbc621d0850 (version 25.3.6.10636.altinitytest (altinity build)) 2025.07.28 11:55:59.497569 [ 5747 ] {104dc703-649a-43a0-909f-c907971958ce} executeQuery: Code: 107. DB::Exception: File /var/lib/clickhouse/user_files/nonexist.txt doesn't exist. (FILE_DOESNT_EXIST) (version 25.3.6.10636.altinitytest (altinity build)) (from [::1]:53774) (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. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000a9b78ab 4. /build/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) @ 0x0000000015d8fd6b 5. /build/src/Planner/PlannerJoinTree.cpp:946: DB::(anonymous namespace)::buildQueryPlanForTableExpression(std::shared_ptr, std::shared_ptr const&, DB::SelectQueryInfo const&, DB::SelectQueryOptions const&, std::shared_ptr&, bool, bool) @ 0x00000000149970ee 6. /build/src/Planner/PlannerJoinTree.cpp:2252: DB::buildJoinTreeQueryPlan(std::shared_ptr const&, DB::SelectQueryInfo const&, DB::SelectQueryOptions&, std::unordered_set, std::equal_to, std::allocator> const&, std::shared_ptr&) @ 0x000000001498e109 7. /build/src/Planner/Planner.cpp:1553: DB::Planner::buildPlanForQueryNode() @ 0x0000000014979dae 8. /build/src/Planner/Planner.cpp:1308: DB::Planner::buildQueryPlanIfNeeded() @ 0x000000001497685c 9. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:255: DB::InterpreterSelectQueryAnalyzer::getQueryPlan() @ 0x000000001497476d 10. /build/src/Interpreters/executeQuery.cpp:1405: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88806 11. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 12. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 13. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 14. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 15. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 16. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 17. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 18. ? @ 0x00007fbc6213eac3 19. ? @ 0x00007fbc621d0850 2025.07.28 11:55:59.511549 [ 5747 ] {} 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. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000a9b78ab 4. /build/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) @ 0x0000000015d8fd6b 5. /build/src/Planner/PlannerJoinTree.cpp:946: DB::(anonymous namespace)::buildQueryPlanForTableExpression(std::shared_ptr, std::shared_ptr const&, DB::SelectQueryInfo const&, DB::SelectQueryOptions const&, std::shared_ptr&, bool, bool) @ 0x00000000149970ee 6. /build/src/Planner/PlannerJoinTree.cpp:2252: DB::buildJoinTreeQueryPlan(std::shared_ptr const&, DB::SelectQueryInfo const&, DB::SelectQueryOptions&, std::unordered_set, std::equal_to, std::allocator> const&, std::shared_ptr&) @ 0x000000001498e109 7. /build/src/Planner/Planner.cpp:1553: DB::Planner::buildPlanForQueryNode() @ 0x0000000014979dae 8. /build/src/Planner/Planner.cpp:1308: DB::Planner::buildQueryPlanIfNeeded() @ 0x000000001497685c 9. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:255: DB::InterpreterSelectQueryAnalyzer::getQueryPlan() @ 0x000000001497476d 10. /build/src/Interpreters/executeQuery.cpp:1405: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88806 11. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 12. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 13. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 14. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 15. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 16. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 17. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 18. ? @ 0x00007fbc6213eac3 19. ? @ 0x00007fbc621d0850 2025.07.28 11:55:59.626609 [ 3960 ] {} test_13.rmt2 (7f9b740d-015c-470e-8cc6-8ba33be0dc63): auto DB::StorageReplicatedMergeTree::processQueueEntry(ReplicatedMergeTreeQueue::SelectedEntryPtr)::(anonymous class)::operator()(LogEntryPtr &) const: Code: 86. DB::HTTPException: Received error from remote server http://146b4357c08d:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Ftest%2F01165%2Ftest_13%2Frmt%2Freplicas%2F1&part=20250728_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.6.10636.altinitytest (altinity build)) '. (RECEIVED_ERROR_FROM_REMOTE_IO_SERVER), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.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 const&, int&&, String const&, unsigned long&&, String const&) @ 0x000000000feda8d9 4. /build/src/IO/HTTPCommon.cpp:104: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x000000000feda6e2 5. /build/src/IO/HTTPCommon.cpp:93: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x000000000feda537 6. /build/src/IO/ReadWriteBufferFromHTTP.cpp:277: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x000000001184a4c4 7. /build/src/IO/ReadWriteBufferFromHTTP.cpp:285: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x000000001184a615 8. /build/src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x000000001184ae59 9. /build/src/IO/ReadWriteBufferFromHTTP.cpp:472: void std::__function::__policy_invoker::__call_impl[abi:se190107]>(std::__function::__policy_storage const*) @ 0x000000001184cedd 10. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001184858b 11. /build/src/IO/ReadWriteBufferFromHTTP.cpp:465: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x000000001184bf0b 12. /build/src/IO/ReadBuffer.h:60: DB::ReadBuffer::next() @ 0x000000000a148c7b 13. /build/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) @ 0x0000000011849fb2 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]>&)>&, 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&) @ 0x0000000011841980 15. /build/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) @ 0x000000001621208e 16. /build/src/Storages/StorageReplicatedMergeTree.cpp:5228: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl[abi:se190107] const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000015f9a5fe 17. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000015ed8bfd 18. /build/src/Storages/StorageReplicatedMergeTree.cpp:2514: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x0000000015ec9aab 19. /build/src/Storages/StorageReplicatedMergeTree.cpp:2349: DB::StorageReplicatedMergeTree::executeLogEntry(DB::ReplicatedMergeTreeLogEntry&) @ 0x0000000015eba91b 20. /build/src/Storages/StorageReplicatedMergeTree.cpp:3876: bool std::__function::__policy_invoker&)>::__call_impl[abi:se190107])::$_1, bool (std::shared_ptr&)>>(std::__function::__policy_storage const*, std::shared_ptr&) @ 0x0000000015f9837e 21. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000165d6fc3 22. /build/src/Storages/StorageReplicatedMergeTree.cpp:3872: DB::StorageReplicatedMergeTree::processQueueEntry(std::shared_ptr) @ 0x0000000015efc18a 23. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001624c1b2 24. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000162f9c70 25. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x00000000162fa55a 26. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc6653 27. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000000fccc4c3 28. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc3d92 29. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fcca080 30. ? @ 0x00007fbc6213eac3 31. ? @ 0x00007fbc621d0850 (version 25.3.6.10636.altinitytest (altinity build)) 2025.07.28 11:55:59.644867 [ 7630 ] {} 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. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception>&, String>(int, FormatStringHelperImpl>&>::type, std::type_identity::type>, std::basic_string_view>&, String&&) @ 0x000000001385a5eb 4. /build/src/Access/SettingsConstraints.cpp:376: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000013859b18 5. /build/src/Access/SettingsConstraints.cpp:300: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000013858faf 6. /build/src/Access/SettingsConstraints.cpp:209: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000013859223 7. /build/src/Interpreters/Context.cpp:2690: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000014436134 8. /build/src/Interpreters/Context.cpp:2729: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x000000001443662b 9. /build/src/Server/HTTPHandler.cpp:457: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000001686d165 10. /build/src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x0000000016870807 11. /build/src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x0000000016907e99 12. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 13. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 14. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 15. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 16. ? @ 0x00007fbc6213eac3 17. ? @ 0x00007fbc621d0850 (version 25.3.6.10636.altinitytest (altinity build)) 2025.07.28 11:56:00.137722 [ 3961 ] {} test_13.rmt2 (7f9b740d-015c-470e-8cc6-8ba33be0dc63): auto DB::StorageReplicatedMergeTree::processQueueEntry(ReplicatedMergeTreeQueue::SelectedEntryPtr)::(anonymous class)::operator()(LogEntryPtr &) const: Code: 86. DB::HTTPException: Received error from remote server http://146b4357c08d:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Ftest%2F01165%2Ftest_13%2Frmt%2Freplicas%2F1&part=20250728_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.6.10636.altinitytest (altinity build)) '. (RECEIVED_ERROR_FROM_REMOTE_IO_SERVER), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.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 const&, int&&, String const&, unsigned long&&, String const&) @ 0x000000000feda8d9 4. /build/src/IO/HTTPCommon.cpp:104: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x000000000feda6e2 5. /build/src/IO/HTTPCommon.cpp:93: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x000000000feda537 6. /build/src/IO/ReadWriteBufferFromHTTP.cpp:277: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x000000001184a4c4 7. /build/src/IO/ReadWriteBufferFromHTTP.cpp:285: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x000000001184a615 8. /build/src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x000000001184ae59 9. /build/src/IO/ReadWriteBufferFromHTTP.cpp:472: void std::__function::__policy_invoker::__call_impl[abi:se190107]>(std::__function::__policy_storage const*) @ 0x000000001184cedd 10. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001184858b 11. /build/src/IO/ReadWriteBufferFromHTTP.cpp:465: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x000000001184bf0b 12. /build/src/IO/ReadBuffer.h:60: DB::ReadBuffer::next() @ 0x000000000a148c7b 13. /build/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) @ 0x0000000011849fb2 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]>&)>&, 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&) @ 0x0000000011841980 15. /build/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) @ 0x000000001621208e 16. /build/src/Storages/StorageReplicatedMergeTree.cpp:5228: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl[abi:se190107] const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000015f9a5fe 17. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000015ed8bfd 18. /build/src/Storages/StorageReplicatedMergeTree.cpp:2514: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x0000000015ec9aab 19. /build/src/Storages/StorageReplicatedMergeTree.cpp:2349: DB::StorageReplicatedMergeTree::executeLogEntry(DB::ReplicatedMergeTreeLogEntry&) @ 0x0000000015eba91b 20. /build/src/Storages/StorageReplicatedMergeTree.cpp:3876: bool std::__function::__policy_invoker&)>::__call_impl[abi:se190107])::$_1, bool (std::shared_ptr&)>>(std::__function::__policy_storage const*, std::shared_ptr&) @ 0x0000000015f9837e 21. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000165d6fc3 22. /build/src/Storages/StorageReplicatedMergeTree.cpp:3872: DB::StorageReplicatedMergeTree::processQueueEntry(std::shared_ptr) @ 0x0000000015efc18a 23. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001624c1b2 24. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000162f9c70 25. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x00000000162fa55a 26. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc6653 27. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000000fccc4c3 28. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc3d92 29. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fcca080 30. ? @ 0x00007fbc6213eac3 31. ? @ 0x00007fbc621d0850 (version 25.3.6.10636.altinitytest (altinity build)) 2025.07.28 11:56:00.259894 [ 3977 ] {} test_13.rmt2 (7f9b740d-015c-470e-8cc6-8ba33be0dc63): auto DB::StorageReplicatedMergeTree::processQueueEntry(ReplicatedMergeTreeQueue::SelectedEntryPtr)::(anonymous class)::operator()(LogEntryPtr &) const: Code: 86. DB::HTTPException: Received error from remote server http://146b4357c08d:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Ftest%2F01165%2Ftest_13%2Frmt%2Freplicas%2F1&part=20250728_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.6.10636.altinitytest (altinity build)) '. (RECEIVED_ERROR_FROM_REMOTE_IO_SERVER), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.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 const&, int&&, String const&, unsigned long&&, String const&) @ 0x000000000feda8d9 4. /build/src/IO/HTTPCommon.cpp:104: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x000000000feda6e2 5. /build/src/IO/HTTPCommon.cpp:93: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x000000000feda537 6. /build/src/IO/ReadWriteBufferFromHTTP.cpp:277: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x000000001184a4c4 7. /build/src/IO/ReadWriteBufferFromHTTP.cpp:285: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x000000001184a615 8. /build/src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x000000001184ae59 9. /build/src/IO/ReadWriteBufferFromHTTP.cpp:472: void std::__function::__policy_invoker::__call_impl[abi:se190107]>(std::__function::__policy_storage const*) @ 0x000000001184cedd 10. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001184858b 11. /build/src/IO/ReadWriteBufferFromHTTP.cpp:465: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x000000001184bf0b 12. /build/src/IO/ReadBuffer.h:60: DB::ReadBuffer::next() @ 0x000000000a148c7b 13. /build/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) @ 0x0000000011849fb2 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]>&)>&, 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&) @ 0x0000000011841980 15. /build/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) @ 0x000000001621208e 16. /build/src/Storages/StorageReplicatedMergeTree.cpp:5228: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl[abi:se190107] const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000015f9a5fe 17. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000015ed8bfd 18. /build/src/Storages/StorageReplicatedMergeTree.cpp:2514: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x0000000015ec9aab 19. /build/src/Storages/StorageReplicatedMergeTree.cpp:2349: DB::StorageReplicatedMergeTree::executeLogEntry(DB::ReplicatedMergeTreeLogEntry&) @ 0x0000000015eba91b 20. /build/src/Storages/StorageReplicatedMergeTree.cpp:3876: bool std::__function::__policy_invoker&)>::__call_impl[abi:se190107])::$_1, bool (std::shared_ptr&)>>(std::__function::__policy_storage const*, std::shared_ptr&) @ 0x0000000015f9837e 21. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000165d6fc3 22. /build/src/Storages/StorageReplicatedMergeTree.cpp:3872: DB::StorageReplicatedMergeTree::processQueueEntry(std::shared_ptr) @ 0x0000000015efc18a 23. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001624c1b2 24. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000162f9c70 25. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x00000000162fa55a 26. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc6653 27. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000000fccc4c3 28. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc3d92 29. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fcca080 30. ? @ 0x00007fbc6213eac3 31. ? @ 0x00007fbc621d0850 (version 25.3.6.10636.altinitytest (altinity build)) 2025.07.28 11:56:00.799864 [ 7630 ] {} 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. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception>&, String>(int, FormatStringHelperImpl>&>::type, std::type_identity::type>, std::basic_string_view>&, String&&) @ 0x000000001385a5eb 4. /build/src/Access/SettingsConstraints.cpp:376: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000013859b18 5. /build/src/Access/SettingsConstraints.cpp:300: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000013858faf 6. /build/src/Access/SettingsConstraints.cpp:209: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000013859223 7. /build/src/Interpreters/Context.cpp:2690: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000014436134 8. /build/src/Interpreters/Context.cpp:2729: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x000000001443662b 9. /build/src/Server/HTTPHandler.cpp:457: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000001686d165 10. /build/src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x0000000016870807 11. /build/src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x0000000016907e99 12. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 13. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 14. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 15. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 16. ? @ 0x00007fbc6213eac3 17. ? @ 0x00007fbc621d0850 (version 25.3.6.10636.altinitytest (altinity build)) 2025.07.28 11:56:01.300113 [ 3963 ] {} test_13.rmt2 (7f9b740d-015c-470e-8cc6-8ba33be0dc63): auto DB::StorageReplicatedMergeTree::processQueueEntry(ReplicatedMergeTreeQueue::SelectedEntryPtr)::(anonymous class)::operator()(LogEntryPtr &) const: Code: 86. DB::HTTPException: Received error from remote server http://146b4357c08d:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Ftest%2F01165%2Ftest_13%2Frmt%2Freplicas%2F1&part=20250728_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.6.10636.altinitytest (altinity build)) '. (RECEIVED_ERROR_FROM_REMOTE_IO_SERVER), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.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 const&, int&&, String const&, unsigned long&&, String const&) @ 0x000000000feda8d9 4. /build/src/IO/HTTPCommon.cpp:104: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x000000000feda6e2 5. /build/src/IO/HTTPCommon.cpp:93: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x000000000feda537 6. /build/src/IO/ReadWriteBufferFromHTTP.cpp:277: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x000000001184a4c4 7. /build/src/IO/ReadWriteBufferFromHTTP.cpp:285: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x000000001184a615 8. /build/src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x000000001184ae59 9. /build/src/IO/ReadWriteBufferFromHTTP.cpp:472: void std::__function::__policy_invoker::__call_impl[abi:se190107]>(std::__function::__policy_storage const*) @ 0x000000001184cedd 10. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001184858b 11. /build/src/IO/ReadWriteBufferFromHTTP.cpp:465: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x000000001184bf0b 12. /build/src/IO/ReadBuffer.h:60: DB::ReadBuffer::next() @ 0x000000000a148c7b 13. /build/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) @ 0x0000000011849fb2 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]>&)>&, 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&) @ 0x0000000011841980 15. /build/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) @ 0x000000001621208e 16. /build/src/Storages/StorageReplicatedMergeTree.cpp:5228: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl[abi:se190107] const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000015f9a5fe 17. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000015ed8bfd 18. /build/src/Storages/StorageReplicatedMergeTree.cpp:2514: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x0000000015ec9aab 19. /build/src/Storages/StorageReplicatedMergeTree.cpp:2349: DB::StorageReplicatedMergeTree::executeLogEntry(DB::ReplicatedMergeTreeLogEntry&) @ 0x0000000015eba91b 20. /build/src/Storages/StorageReplicatedMergeTree.cpp:3876: bool std::__function::__policy_invoker&)>::__call_impl[abi:se190107])::$_1, bool (std::shared_ptr&)>>(std::__function::__policy_storage const*, std::shared_ptr&) @ 0x0000000015f9837e 21. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000165d6fc3 22. /build/src/Storages/StorageReplicatedMergeTree.cpp:3872: DB::StorageReplicatedMergeTree::processQueueEntry(std::shared_ptr) @ 0x0000000015efc18a 23. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001624c1b2 24. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000162f9c70 25. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x00000000162fa55a 26. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc6653 27. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000000fccc4c3 28. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc3d92 29. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fcca080 30. ? @ 0x00007fbc6213eac3 31. ? @ 0x00007fbc621d0850 (version 25.3.6.10636.altinitytest (altinity build)) 2025.07.28 11:56:02.077944 [ 3962 ] {} test_13.rmt2 (7f9b740d-015c-470e-8cc6-8ba33be0dc63): auto DB::StorageReplicatedMergeTree::processQueueEntry(ReplicatedMergeTreeQueue::SelectedEntryPtr)::(anonymous class)::operator()(LogEntryPtr &) const: Code: 86. DB::HTTPException: Received error from remote server http://146b4357c08d:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Ftest%2F01165%2Ftest_13%2Frmt%2Freplicas%2F1&part=20250728_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.6.10636.altinitytest (altinity build)) '. (RECEIVED_ERROR_FROM_REMOTE_IO_SERVER), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.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 const&, int&&, String const&, unsigned long&&, String const&) @ 0x000000000feda8d9 4. /build/src/IO/HTTPCommon.cpp:104: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x000000000feda6e2 5. /build/src/IO/HTTPCommon.cpp:93: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x000000000feda537 6. /build/src/IO/ReadWriteBufferFromHTTP.cpp:277: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x000000001184a4c4 7. /build/src/IO/ReadWriteBufferFromHTTP.cpp:285: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x000000001184a615 8. /build/src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x000000001184ae59 9. /build/src/IO/ReadWriteBufferFromHTTP.cpp:472: void std::__function::__policy_invoker::__call_impl[abi:se190107]>(std::__function::__policy_storage const*) @ 0x000000001184cedd 10. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001184858b 11. /build/src/IO/ReadWriteBufferFromHTTP.cpp:465: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x000000001184bf0b 12. /build/src/IO/ReadBuffer.h:60: DB::ReadBuffer::next() @ 0x000000000a148c7b 13. /build/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) @ 0x0000000011849fb2 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]>&)>&, 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&) @ 0x0000000011841980 15. /build/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) @ 0x000000001621208e 16. /build/src/Storages/StorageReplicatedMergeTree.cpp:5228: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl[abi:se190107] const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000015f9a5fe 17. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000015ed8bfd 18. /build/src/Storages/StorageReplicatedMergeTree.cpp:2514: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x0000000015ec9aab 19. /build/src/Storages/StorageReplicatedMergeTree.cpp:2349: DB::StorageReplicatedMergeTree::executeLogEntry(DB::ReplicatedMergeTreeLogEntry&) @ 0x0000000015eba91b 20. /build/src/Storages/StorageReplicatedMergeTree.cpp:3876: bool std::__function::__policy_invoker&)>::__call_impl[abi:se190107])::$_1, bool (std::shared_ptr&)>>(std::__function::__policy_storage const*, std::shared_ptr&) @ 0x0000000015f9837e 21. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000165d6fc3 22. /build/src/Storages/StorageReplicatedMergeTree.cpp:3872: DB::StorageReplicatedMergeTree::processQueueEntry(std::shared_ptr) @ 0x0000000015efc18a 23. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001624c1b2 24. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000162f9c70 25. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x00000000162fa55a 26. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc6653 27. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000000fccc4c3 28. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc3d92 29. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fcca080 30. ? @ 0x00007fbc6213eac3 31. ? @ 0x00007fbc621d0850 (version 25.3.6.10636.altinitytest (altinity build)) 2025.07.28 11:56:02.515805 [ 3976 ] {} test_13.rmt2 (7f9b740d-015c-470e-8cc6-8ba33be0dc63): auto DB::StorageReplicatedMergeTree::processQueueEntry(ReplicatedMergeTreeQueue::SelectedEntryPtr)::(anonymous class)::operator()(LogEntryPtr &) const: Code: 86. DB::HTTPException: Received error from remote server http://146b4357c08d:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Ftest%2F01165%2Ftest_13%2Frmt%2Freplicas%2F1&part=20250728_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.6.10636.altinitytest (altinity build)) '. (RECEIVED_ERROR_FROM_REMOTE_IO_SERVER), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.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 const&, int&&, String const&, unsigned long&&, String const&) @ 0x000000000feda8d9 4. /build/src/IO/HTTPCommon.cpp:104: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x000000000feda6e2 5. /build/src/IO/HTTPCommon.cpp:93: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x000000000feda537 6. /build/src/IO/ReadWriteBufferFromHTTP.cpp:277: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x000000001184a4c4 7. /build/src/IO/ReadWriteBufferFromHTTP.cpp:285: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x000000001184a615 8. /build/src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x000000001184ae59 9. /build/src/IO/ReadWriteBufferFromHTTP.cpp:472: void std::__function::__policy_invoker::__call_impl[abi:se190107]>(std::__function::__policy_storage const*) @ 0x000000001184cedd 10. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001184858b 11. /build/src/IO/ReadWriteBufferFromHTTP.cpp:465: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x000000001184bf0b 12. /build/src/IO/ReadBuffer.h:60: DB::ReadBuffer::next() @ 0x000000000a148c7b 13. /build/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) @ 0x0000000011849fb2 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]>&)>&, 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&) @ 0x0000000011841980 15. /build/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) @ 0x000000001621208e 16. /build/src/Storages/StorageReplicatedMergeTree.cpp:5228: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl[abi:se190107] const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000015f9a5fe 17. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000015ed8bfd 18. /build/src/Storages/StorageReplicatedMergeTree.cpp:2514: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x0000000015ec9aab 19. /build/src/Storages/StorageReplicatedMergeTree.cpp:2349: DB::StorageReplicatedMergeTree::executeLogEntry(DB::ReplicatedMergeTreeLogEntry&) @ 0x0000000015eba91b 20. /build/src/Storages/StorageReplicatedMergeTree.cpp:3876: bool std::__function::__policy_invoker&)>::__call_impl[abi:se190107])::$_1, bool (std::shared_ptr&)>>(std::__function::__policy_storage const*, std::shared_ptr&) @ 0x0000000015f9837e 21. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000165d6fc3 22. /build/src/Storages/StorageReplicatedMergeTree.cpp:3872: DB::StorageReplicatedMergeTree::processQueueEntry(std::shared_ptr) @ 0x0000000015efc18a 23. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001624c1b2 24. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000162f9c70 25. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x00000000162fa55a 26. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc6653 27. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000000fccc4c3 28. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc3d92 29. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fcca080 30. ? @ 0x00007fbc6213eac3 31. ? @ 0x00007fbc621d0850 (version 25.3.6.10636.altinitytest (altinity build)) 2025.07.28 11:56:03.000079 [ 17306 ] {981d4148-5f81-459b-97d2-8bf7ff27029b} executeQuery: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION) (version 25.3.6.10636.altinitytest (altinity build)) (from [::1]:60934) (comment: 02834_array_exists_segfault.sql) (query 3, line 3) (in query: SET enable_analyzer = 0;), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x000000000c25bc4b 4. /build/src/Access/SettingsConstraints.cpp:343: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000138596e3 5. /build/src/Access/SettingsConstraints.cpp:300: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000013858faf 6. /build/src/Access/SettingsConstraints.cpp:194: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges const&, DB::SettingSource) const @ 0x00000000138591b3 7. /build/src/Interpreters/Context.cpp:2722: DB::Context::checkSettingsConstraints(DB::SettingsChanges const&, DB::SettingSource) @ 0x0000000014436509 8. /build/src/Interpreters/InterpreterSetQuery.cpp:28: DB::InterpreterSetQuery::execute() @ 0x00000000149e240a 9. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88dc9 10. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 11. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 12. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 13. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 14. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 16. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 17. ? @ 0x00007fbc6213eac3 18. ? @ 0x00007fbc621d0850 2025.07.28 11:56:03.017660 [ 17306 ] {} 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. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x000000000c25bc4b 4. /build/src/Access/SettingsConstraints.cpp:343: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000138596e3 5. /build/src/Access/SettingsConstraints.cpp:300: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000013858faf 6. /build/src/Access/SettingsConstraints.cpp:194: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges const&, DB::SettingSource) const @ 0x00000000138591b3 7. /build/src/Interpreters/Context.cpp:2722: DB::Context::checkSettingsConstraints(DB::SettingsChanges const&, DB::SettingSource) @ 0x0000000014436509 8. /build/src/Interpreters/InterpreterSetQuery.cpp:28: DB::InterpreterSetQuery::execute() @ 0x00000000149e240a 9. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88dc9 10. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 11. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 12. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 13. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 14. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 16. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 17. ? @ 0x00007fbc6213eac3 18. ? @ 0x00007fbc621d0850 2025.07.28 11:56:03.176459 [ 3974 ] {} test_13.rmt2 (7f9b740d-015c-470e-8cc6-8ba33be0dc63): auto DB::StorageReplicatedMergeTree::processQueueEntry(ReplicatedMergeTreeQueue::SelectedEntryPtr)::(anonymous class)::operator()(LogEntryPtr &) const: Code: 86. DB::HTTPException: Received error from remote server http://146b4357c08d:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Ftest%2F01165%2Ftest_13%2Frmt%2Freplicas%2F1&part=20250728_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.6.10636.altinitytest (altinity build)) '. (RECEIVED_ERROR_FROM_REMOTE_IO_SERVER), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.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 const&, int&&, String const&, unsigned long&&, String const&) @ 0x000000000feda8d9 4. /build/src/IO/HTTPCommon.cpp:104: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x000000000feda6e2 5. /build/src/IO/HTTPCommon.cpp:93: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x000000000feda537 6. /build/src/IO/ReadWriteBufferFromHTTP.cpp:277: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x000000001184a4c4 7. /build/src/IO/ReadWriteBufferFromHTTP.cpp:285: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x000000001184a615 8. /build/src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x000000001184ae59 9. /build/src/IO/ReadWriteBufferFromHTTP.cpp:472: void std::__function::__policy_invoker::__call_impl[abi:se190107]>(std::__function::__policy_storage const*) @ 0x000000001184cedd 10. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001184858b 11. /build/src/IO/ReadWriteBufferFromHTTP.cpp:465: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x000000001184bf0b 12. /build/src/IO/ReadBuffer.h:60: DB::ReadBuffer::next() @ 0x000000000a148c7b 13. /build/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) @ 0x0000000011849fb2 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]>&)>&, 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&) @ 0x0000000011841980 15. /build/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) @ 0x000000001621208e 16. /build/src/Storages/StorageReplicatedMergeTree.cpp:5228: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl[abi:se190107] const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000015f9a5fe 17. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000015ed8bfd 18. /build/src/Storages/StorageReplicatedMergeTree.cpp:2514: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x0000000015ec9aab 19. /build/src/Storages/StorageReplicatedMergeTree.cpp:2349: DB::StorageReplicatedMergeTree::executeLogEntry(DB::ReplicatedMergeTreeLogEntry&) @ 0x0000000015eba91b 20. /build/src/Storages/StorageReplicatedMergeTree.cpp:3876: bool std::__function::__policy_invoker&)>::__call_impl[abi:se190107])::$_1, bool (std::shared_ptr&)>>(std::__function::__policy_storage const*, std::shared_ptr&) @ 0x0000000015f9837e 21. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000165d6fc3 22. /build/src/Storages/StorageReplicatedMergeTree.cpp:3872: DB::StorageReplicatedMergeTree::processQueueEntry(std::shared_ptr) @ 0x0000000015efc18a 23. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001624c1b2 24. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000162f9c70 25. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x00000000162fa55a 26. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc6653 27. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000000fccc4c3 28. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc3d92 29. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fcca080 30. ? @ 0x00007fbc6213eac3 31. ? @ 0x00007fbc621d0850 (version 25.3.6.10636.altinitytest (altinity build)) 2025.07.28 11:56:03.376739 [ 17207 ] {92c417df-a351-454a-b648-5c841ac64067} executeQuery: Code: 507. DB::Exception: No sharding key. (UNABLE_TO_SKIP_UNUSED_SHARDS) (version 25.3.6.10636.altinitytest (altinity build)) (from [::1]:60888) (comment: 01071_force_optimize_skip_unused_shards.sql) (query 14, line 19) (in query: select * from dist_01071;), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000000a074fcb 4. /build/src/Storages/StorageDistributed.cpp:1556: DB::StorageDistributed::getOptimizedCluster(std::shared_ptr, std::shared_ptr const&, DB::SelectQueryInfo const&, std::shared_ptr const&) const @ 0x0000000015d60895 5. /build/src/Storages/StorageDistributed.cpp:457: DB::StorageDistributed::getQueryProcessingStage(std::shared_ptr, DB::QueryProcessingStage::Enum, std::shared_ptr const&, DB::SelectQueryInfo&) const @ 0x0000000015d5f50d 6. /build/src/Planner/PlannerJoinTree.cpp:921: DB::(anonymous namespace)::buildQueryPlanForTableExpression(std::shared_ptr, std::shared_ptr const&, DB::SelectQueryInfo const&, DB::SelectQueryOptions const&, std::shared_ptr&, bool, bool) @ 0x0000000014996f1b 7. /build/src/Planner/PlannerJoinTree.cpp:2252: DB::buildJoinTreeQueryPlan(std::shared_ptr const&, DB::SelectQueryInfo const&, DB::SelectQueryOptions&, std::unordered_set, std::equal_to, std::allocator> const&, std::shared_ptr&) @ 0x000000001498e109 8. /build/src/Planner/Planner.cpp:1553: DB::Planner::buildPlanForQueryNode() @ 0x0000000014979dae 9. /build/src/Planner/Planner.cpp:1308: DB::Planner::buildQueryPlanIfNeeded() @ 0x000000001497685c 10. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:255: DB::InterpreterSelectQueryAnalyzer::getQueryPlan() @ 0x000000001497476d 11. /build/src/Interpreters/executeQuery.cpp:1405: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88806 12. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 13. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 14. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 15. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 16. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 17. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 18. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 19. ? @ 0x00007fbc6213eac3 20. ? @ 0x00007fbc621d0850 2025.07.28 11:56:03.390932 [ 17207 ] {} TCPHandler: Code: 507. DB::Exception: No sharding key. (UNABLE_TO_SKIP_UNUSED_SHARDS), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000000a074fcb 4. /build/src/Storages/StorageDistributed.cpp:1556: DB::StorageDistributed::getOptimizedCluster(std::shared_ptr, std::shared_ptr const&, DB::SelectQueryInfo const&, std::shared_ptr const&) const @ 0x0000000015d60895 5. /build/src/Storages/StorageDistributed.cpp:457: DB::StorageDistributed::getQueryProcessingStage(std::shared_ptr, DB::QueryProcessingStage::Enum, std::shared_ptr const&, DB::SelectQueryInfo&) const @ 0x0000000015d5f50d 6. /build/src/Planner/PlannerJoinTree.cpp:921: DB::(anonymous namespace)::buildQueryPlanForTableExpression(std::shared_ptr, std::shared_ptr const&, DB::SelectQueryInfo const&, DB::SelectQueryOptions const&, std::shared_ptr&, bool, bool) @ 0x0000000014996f1b 7. /build/src/Planner/PlannerJoinTree.cpp:2252: DB::buildJoinTreeQueryPlan(std::shared_ptr const&, DB::SelectQueryInfo const&, DB::SelectQueryOptions&, std::unordered_set, std::equal_to, std::allocator> const&, std::shared_ptr&) @ 0x000000001498e109 8. /build/src/Planner/Planner.cpp:1553: DB::Planner::buildPlanForQueryNode() @ 0x0000000014979dae 9. /build/src/Planner/Planner.cpp:1308: DB::Planner::buildQueryPlanIfNeeded() @ 0x000000001497685c 10. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:255: DB::InterpreterSelectQueryAnalyzer::getQueryPlan() @ 0x000000001497476d 11. /build/src/Interpreters/executeQuery.cpp:1405: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88806 12. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 13. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 14. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 15. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 16. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 17. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 18. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 19. ? @ 0x00007fbc6213eac3 20. ? @ 0x00007fbc621d0850 2025.07.28 11:56:04.254232 [ 3977 ] {} test_13.rmt2 (7f9b740d-015c-470e-8cc6-8ba33be0dc63): auto DB::StorageReplicatedMergeTree::processQueueEntry(ReplicatedMergeTreeQueue::SelectedEntryPtr)::(anonymous class)::operator()(LogEntryPtr &) const: Code: 86. DB::HTTPException: Received error from remote server http://146b4357c08d:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Ftest%2F01165%2Ftest_13%2Frmt%2Freplicas%2F1&part=20250728_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.6.10636.altinitytest (altinity build)) '. (RECEIVED_ERROR_FROM_REMOTE_IO_SERVER), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.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 const&, int&&, String const&, unsigned long&&, String const&) @ 0x000000000feda8d9 4. /build/src/IO/HTTPCommon.cpp:104: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x000000000feda6e2 5. /build/src/IO/HTTPCommon.cpp:93: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x000000000feda537 6. /build/src/IO/ReadWriteBufferFromHTTP.cpp:277: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x000000001184a4c4 7. /build/src/IO/ReadWriteBufferFromHTTP.cpp:285: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x000000001184a615 8. /build/src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x000000001184ae59 9. /build/src/IO/ReadWriteBufferFromHTTP.cpp:472: void std::__function::__policy_invoker::__call_impl[abi:se190107]>(std::__function::__policy_storage const*) @ 0x000000001184cedd 10. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001184858b 11. /build/src/IO/ReadWriteBufferFromHTTP.cpp:465: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x000000001184bf0b 12. /build/src/IO/ReadBuffer.h:60: DB::ReadBuffer::next() @ 0x000000000a148c7b 13. /build/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) @ 0x0000000011849fb2 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]>&)>&, 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&) @ 0x0000000011841980 15. /build/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) @ 0x000000001621208e 16. /build/src/Storages/StorageReplicatedMergeTree.cpp:5228: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl[abi:se190107] const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000015f9a5fe 17. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000015ed8bfd 18. /build/src/Storages/StorageReplicatedMergeTree.cpp:2514: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x0000000015ec9aab 19. /build/src/Storages/StorageReplicatedMergeTree.cpp:2349: DB::StorageReplicatedMergeTree::executeLogEntry(DB::ReplicatedMergeTreeLogEntry&) @ 0x0000000015eba91b 20. /build/src/Storages/StorageReplicatedMergeTree.cpp:3876: bool std::__function::__policy_invoker&)>::__call_impl[abi:se190107])::$_1, bool (std::shared_ptr&)>>(std::__function::__policy_storage const*, std::shared_ptr&) @ 0x0000000015f9837e 21. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000165d6fc3 22. /build/src/Storages/StorageReplicatedMergeTree.cpp:3872: DB::StorageReplicatedMergeTree::processQueueEntry(std::shared_ptr) @ 0x0000000015efc18a 23. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001624c1b2 24. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000162f9c70 25. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x00000000162fa55a 26. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc6653 27. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000000fccc4c3 28. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc3d92 29. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fcca080 30. ? @ 0x00007fbc6213eac3 31. ? @ 0x00007fbc621d0850 (version 25.3.6.10636.altinitytest (altinity build)) 2025.07.28 11:56:04.282826 [ 17207 ] {bb65b2c3-bf8f-49f4-9a8e-fcb1059ac8fe} executeQuery: Code: 507. DB::Exception: Sharding key modulo(key, 2) is not used. (UNABLE_TO_SKIP_UNUSED_SHARDS) (version 25.3.6.10636.altinitytest (altinity build)) (from [::1]:60888) (comment: 01071_force_optimize_skip_unused_shards.sql) (query 20, line 26) (in query: select * from dist_01071;), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000a9b78ab 4. /build/src/Storages/StorageDistributed.cpp:1559: DB::StorageDistributed::getOptimizedCluster(std::shared_ptr, std::shared_ptr const&, DB::SelectQueryInfo const&, std::shared_ptr const&) const @ 0x0000000015d6083b 5. /build/src/Storages/StorageDistributed.cpp:457: DB::StorageDistributed::getQueryProcessingStage(std::shared_ptr, DB::QueryProcessingStage::Enum, std::shared_ptr const&, DB::SelectQueryInfo&) const @ 0x0000000015d5f50d 6. /build/src/Planner/PlannerJoinTree.cpp:921: DB::(anonymous namespace)::buildQueryPlanForTableExpression(std::shared_ptr, std::shared_ptr const&, DB::SelectQueryInfo const&, DB::SelectQueryOptions const&, std::shared_ptr&, bool, bool) @ 0x0000000014996f1b 7. /build/src/Planner/PlannerJoinTree.cpp:2252: DB::buildJoinTreeQueryPlan(std::shared_ptr const&, DB::SelectQueryInfo const&, DB::SelectQueryOptions&, std::unordered_set, std::equal_to, std::allocator> const&, std::shared_ptr&) @ 0x000000001498e109 8. /build/src/Planner/Planner.cpp:1553: DB::Planner::buildPlanForQueryNode() @ 0x0000000014979dae 9. /build/src/Planner/Planner.cpp:1308: DB::Planner::buildQueryPlanIfNeeded() @ 0x000000001497685c 10. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:255: DB::InterpreterSelectQueryAnalyzer::getQueryPlan() @ 0x000000001497476d 11. /build/src/Interpreters/executeQuery.cpp:1405: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88806 12. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 13. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 14. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 15. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 16. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 17. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 18. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 19. ? @ 0x00007fbc6213eac3 20. ? @ 0x00007fbc621d0850 2025.07.28 11:56:04.287972 [ 17207 ] {} TCPHandler: Code: 507. DB::Exception: Sharding key modulo(key, 2) is not used. (UNABLE_TO_SKIP_UNUSED_SHARDS), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000a9b78ab 4. /build/src/Storages/StorageDistributed.cpp:1559: DB::StorageDistributed::getOptimizedCluster(std::shared_ptr, std::shared_ptr const&, DB::SelectQueryInfo const&, std::shared_ptr const&) const @ 0x0000000015d6083b 5. /build/src/Storages/StorageDistributed.cpp:457: DB::StorageDistributed::getQueryProcessingStage(std::shared_ptr, DB::QueryProcessingStage::Enum, std::shared_ptr const&, DB::SelectQueryInfo&) const @ 0x0000000015d5f50d 6. /build/src/Planner/PlannerJoinTree.cpp:921: DB::(anonymous namespace)::buildQueryPlanForTableExpression(std::shared_ptr, std::shared_ptr const&, DB::SelectQueryInfo const&, DB::SelectQueryOptions const&, std::shared_ptr&, bool, bool) @ 0x0000000014996f1b 7. /build/src/Planner/PlannerJoinTree.cpp:2252: DB::buildJoinTreeQueryPlan(std::shared_ptr const&, DB::SelectQueryInfo const&, DB::SelectQueryOptions&, std::unordered_set, std::equal_to, std::allocator> const&, std::shared_ptr&) @ 0x000000001498e109 8. /build/src/Planner/Planner.cpp:1553: DB::Planner::buildPlanForQueryNode() @ 0x0000000014979dae 9. /build/src/Planner/Planner.cpp:1308: DB::Planner::buildQueryPlanIfNeeded() @ 0x000000001497685c 10. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:255: DB::InterpreterSelectQueryAnalyzer::getQueryPlan() @ 0x000000001497476d 11. /build/src/Interpreters/executeQuery.cpp:1405: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88806 12. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 13. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 14. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 15. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 16. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 17. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 18. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 19. ? @ 0x00007fbc6213eac3 20. ? @ 0x00007fbc621d0850 2025.07.28 11:56:04.484646 [ 4963 ] {375bb1a7-f22d-4fa9-900d-a85cf394f04a} executeQuery: Code: 252. DB::Exception: Too many inactive parts (2) in table 'test_uvymies9.data_01709 (2fd71a57-2f8d-4dd3-919a-682e1a34834a)'. Parts cleaning are processing significantly slower than inserts. (TOO_MANY_PARTS) (version 25.3.6.10636.altinitytest (altinity build)) (from [::1]:60964) (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. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, unsigned long&, String&&) @ 0x000000000ba5db6b 4. /build/src/Storages/MergeTree/MergeTreeData.cpp:4913: DB::MergeTreeData::delayInsertOrThrowIfNeeded(Poco::Event*, std::shared_ptr const&, bool) const @ 0x000000001634e8ab 5. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000016c0abf5 6. /build/src/Processors/Transforms/ExceptionKeepingTransform.cpp:137: DB::ExceptionKeepingTransform::work() @ 0x0000000016c0a63d 7. /build/src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x00000000169bd00f 8. /build/src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x00000000169b2105 9. /build/src/Processors/Executors/PipelineExecutor.cpp:170: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x00000000169b16a7 10. /build/src/Processors/Executors/PushingPipelineExecutor.cpp:103: DB::PushingPipelineExecutor::start() @ 0x00000000169c3125 11. /build/src/Server/TCPHandler.cpp:1113: DB::TCPHandler::processInsertQuery(DB::QueryState&) @ 0x00000000168f049d 12. /build/src/Server/TCPHandler.cpp:673: DB::TCPHandler::runImpl() @ 0x00000000168e68bc 13. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 14. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 15. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 16. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 17. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 18. ? @ 0x00007fbc6213eac3 19. ? @ 0x00007fbc621d0850 2025.07.28 11:56:04.487512 [ 4963 ] {} TCPHandler: Code: 252. DB::Exception: Too many inactive parts (2) in table 'test_uvymies9.data_01709 (2fd71a57-2f8d-4dd3-919a-682e1a34834a)'. Parts cleaning are processing significantly slower than inserts. (TOO_MANY_PARTS), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, unsigned long&, String&&) @ 0x000000000ba5db6b 4. /build/src/Storages/MergeTree/MergeTreeData.cpp:4913: DB::MergeTreeData::delayInsertOrThrowIfNeeded(Poco::Event*, std::shared_ptr const&, bool) const @ 0x000000001634e8ab 5. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000016c0abf5 6. /build/src/Processors/Transforms/ExceptionKeepingTransform.cpp:137: DB::ExceptionKeepingTransform::work() @ 0x0000000016c0a63d 7. /build/src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x00000000169bd00f 8. /build/src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x00000000169b2105 9. /build/src/Processors/Executors/PipelineExecutor.cpp:170: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x00000000169b16a7 10. /build/src/Processors/Executors/PushingPipelineExecutor.cpp:103: DB::PushingPipelineExecutor::start() @ 0x00000000169c3125 11. /build/src/Server/TCPHandler.cpp:1113: DB::TCPHandler::processInsertQuery(DB::QueryState&) @ 0x00000000168f049d 12. /build/src/Server/TCPHandler.cpp:673: DB::TCPHandler::runImpl() @ 0x00000000168e68bc 13. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 14. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 15. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 16. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 17. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 18. ? @ 0x00007fbc6213eac3 19. ? @ 0x00007fbc621d0850 2025.07.28 11:56:04.498655 [ 17207 ] {14bbfebe-b591-4fee-bc1f-f9e76f1eee07} executeQuery: Code: 507. DB::Exception: Sharding key modulo(key, 2) is not used. (UNABLE_TO_SKIP_UNUSED_SHARDS) (version 25.3.6.10636.altinitytest (altinity build)) (from [::1]:60888) (comment: 01071_force_optimize_skip_unused_shards.sql) (query 22, line 28) (in query: select * from dist_01071;), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000a9b78ab 4. /build/src/Storages/StorageDistributed.cpp:1559: DB::StorageDistributed::getOptimizedCluster(std::shared_ptr, std::shared_ptr const&, DB::SelectQueryInfo const&, std::shared_ptr const&) const @ 0x0000000015d6083b 5. /build/src/Storages/StorageDistributed.cpp:457: DB::StorageDistributed::getQueryProcessingStage(std::shared_ptr, DB::QueryProcessingStage::Enum, std::shared_ptr const&, DB::SelectQueryInfo&) const @ 0x0000000015d5f50d 6. /build/src/Planner/PlannerJoinTree.cpp:921: DB::(anonymous namespace)::buildQueryPlanForTableExpression(std::shared_ptr, std::shared_ptr const&, DB::SelectQueryInfo const&, DB::SelectQueryOptions const&, std::shared_ptr&, bool, bool) @ 0x0000000014996f1b 7. /build/src/Planner/PlannerJoinTree.cpp:2252: DB::buildJoinTreeQueryPlan(std::shared_ptr const&, DB::SelectQueryInfo const&, DB::SelectQueryOptions&, std::unordered_set, std::equal_to, std::allocator> const&, std::shared_ptr&) @ 0x000000001498e109 8. /build/src/Planner/Planner.cpp:1553: DB::Planner::buildPlanForQueryNode() @ 0x0000000014979dae 9. /build/src/Planner/Planner.cpp:1308: DB::Planner::buildQueryPlanIfNeeded() @ 0x000000001497685c 10. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:255: DB::InterpreterSelectQueryAnalyzer::getQueryPlan() @ 0x000000001497476d 11. /build/src/Interpreters/executeQuery.cpp:1405: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88806 12. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 13. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 14. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 15. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 16. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 17. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 18. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 19. ? @ 0x00007fbc6213eac3 20. ? @ 0x00007fbc621d0850 2025.07.28 11:56:04.501404 [ 17207 ] {} TCPHandler: Code: 507. DB::Exception: Sharding key modulo(key, 2) is not used. (UNABLE_TO_SKIP_UNUSED_SHARDS), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000a9b78ab 4. /build/src/Storages/StorageDistributed.cpp:1559: DB::StorageDistributed::getOptimizedCluster(std::shared_ptr, std::shared_ptr const&, DB::SelectQueryInfo const&, std::shared_ptr const&) const @ 0x0000000015d6083b 5. /build/src/Storages/StorageDistributed.cpp:457: DB::StorageDistributed::getQueryProcessingStage(std::shared_ptr, DB::QueryProcessingStage::Enum, std::shared_ptr const&, DB::SelectQueryInfo&) const @ 0x0000000015d5f50d 6. /build/src/Planner/PlannerJoinTree.cpp:921: DB::(anonymous namespace)::buildQueryPlanForTableExpression(std::shared_ptr, std::shared_ptr const&, DB::SelectQueryInfo const&, DB::SelectQueryOptions const&, std::shared_ptr&, bool, bool) @ 0x0000000014996f1b 7. /build/src/Planner/PlannerJoinTree.cpp:2252: DB::buildJoinTreeQueryPlan(std::shared_ptr const&, DB::SelectQueryInfo const&, DB::SelectQueryOptions&, std::unordered_set, std::equal_to, std::allocator> const&, std::shared_ptr&) @ 0x000000001498e109 8. /build/src/Planner/Planner.cpp:1553: DB::Planner::buildPlanForQueryNode() @ 0x0000000014979dae 9. /build/src/Planner/Planner.cpp:1308: DB::Planner::buildQueryPlanIfNeeded() @ 0x000000001497685c 10. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:255: DB::InterpreterSelectQueryAnalyzer::getQueryPlan() @ 0x000000001497476d 11. /build/src/Interpreters/executeQuery.cpp:1405: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88806 12. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 13. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 14. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 15. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 16. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 17. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 18. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 19. ? @ 0x00007fbc6213eac3 20. ? @ 0x00007fbc621d0850 2025.07.28 11:56:04.808226 [ 17207 ] {f8a557ff-27f7-4c51-a14d-caf26c825ffc} executeQuery: Code: 507. DB::Exception: Sharding key is not deterministic. (UNABLE_TO_SKIP_UNUSED_SHARDS) (version 25.3.6.10636.altinitytest (altinity build)) (from [::1]:60888) (comment: 01071_force_optimize_skip_unused_shards.sql) (query 26, line 34) (in query: select * from dist_01071 where key = 0;), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000000a074fcb 4. /build/src/Storages/StorageDistributed.cpp:1558: DB::StorageDistributed::getOptimizedCluster(std::shared_ptr, std::shared_ptr const&, DB::SelectQueryInfo const&, std::shared_ptr const&) const @ 0x0000000015d608d8 5. /build/src/Storages/StorageDistributed.cpp:457: DB::StorageDistributed::getQueryProcessingStage(std::shared_ptr, DB::QueryProcessingStage::Enum, std::shared_ptr const&, DB::SelectQueryInfo&) const @ 0x0000000015d5f50d 6. /build/src/Planner/PlannerJoinTree.cpp:921: DB::(anonymous namespace)::buildQueryPlanForTableExpression(std::shared_ptr, std::shared_ptr const&, DB::SelectQueryInfo const&, DB::SelectQueryOptions const&, std::shared_ptr&, bool, bool) @ 0x0000000014996f1b 7. /build/src/Planner/PlannerJoinTree.cpp:2252: DB::buildJoinTreeQueryPlan(std::shared_ptr const&, DB::SelectQueryInfo const&, DB::SelectQueryOptions&, std::unordered_set, std::equal_to, std::allocator> const&, std::shared_ptr&) @ 0x000000001498e109 8. /build/src/Planner/Planner.cpp:1553: DB::Planner::buildPlanForQueryNode() @ 0x0000000014979dae 9. /build/src/Planner/Planner.cpp:1308: DB::Planner::buildQueryPlanIfNeeded() @ 0x000000001497685c 10. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:255: DB::InterpreterSelectQueryAnalyzer::getQueryPlan() @ 0x000000001497476d 11. /build/src/Interpreters/executeQuery.cpp:1405: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88806 12. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 13. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 14. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 15. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 16. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 17. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 18. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 19. ? @ 0x00007fbc6213eac3 20. ? @ 0x00007fbc621d0850 2025.07.28 11:56:04.811127 [ 17207 ] {} 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. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000000a074fcb 4. /build/src/Storages/StorageDistributed.cpp:1558: DB::StorageDistributed::getOptimizedCluster(std::shared_ptr, std::shared_ptr const&, DB::SelectQueryInfo const&, std::shared_ptr const&) const @ 0x0000000015d608d8 5. /build/src/Storages/StorageDistributed.cpp:457: DB::StorageDistributed::getQueryProcessingStage(std::shared_ptr, DB::QueryProcessingStage::Enum, std::shared_ptr const&, DB::SelectQueryInfo&) const @ 0x0000000015d5f50d 6. /build/src/Planner/PlannerJoinTree.cpp:921: DB::(anonymous namespace)::buildQueryPlanForTableExpression(std::shared_ptr, std::shared_ptr const&, DB::SelectQueryInfo const&, DB::SelectQueryOptions const&, std::shared_ptr&, bool, bool) @ 0x0000000014996f1b 7. /build/src/Planner/PlannerJoinTree.cpp:2252: DB::buildJoinTreeQueryPlan(std::shared_ptr const&, DB::SelectQueryInfo const&, DB::SelectQueryOptions&, std::unordered_set, std::equal_to, std::allocator> const&, std::shared_ptr&) @ 0x000000001498e109 8. /build/src/Planner/Planner.cpp:1553: DB::Planner::buildPlanForQueryNode() @ 0x0000000014979dae 9. /build/src/Planner/Planner.cpp:1308: DB::Planner::buildQueryPlanIfNeeded() @ 0x000000001497685c 10. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:255: DB::InterpreterSelectQueryAnalyzer::getQueryPlan() @ 0x000000001497476d 11. /build/src/Interpreters/executeQuery.cpp:1405: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88806 12. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 13. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 14. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 15. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 16. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 17. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 18. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 19. ? @ 0x00007fbc6213eac3 20. ? @ 0x00007fbc621d0850 2025.07.28 11:56:04.859131 [ 17232 ] {99113dab-039c-4c24-8f13-46608172a8c9} executeQuery: Code: 219. DB::Exception: New table appeared in database being dropped or detached. Try again. (DATABASE_NOT_EMPTY) (version 25.3.6.10636.altinitytest (altinity build)) (from [::1]:43960) (comment: 01014_count_of_merges_metrics.sql) (in query: DROP DATABASE IF EXISTS test_thorkaeo SYNC ), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000000a074fcb 4. /build/src/Interpreters/DatabaseCatalog.cpp:608: DB::DatabaseCatalog::detachDatabase(std::shared_ptr, String const&, bool, bool) @ 0x00000000144f41b9 5. /build/src/Interpreters/InterpreterDropQuery.cpp:482: DB::InterpreterDropQuery::executeToDatabaseImpl(DB::ASTDropQuery const&, std::shared_ptr&, std::vector, DB::UUIDTag>, std::allocator, DB::UUIDTag>>>&) @ 0x00000000149179be 6. /build/src/Interpreters/InterpreterDropQuery.cpp:363: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x0000000014913988 7. /build/src/Interpreters/InterpreterDropQuery.cpp:99: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000014913142 8. /build/src/Interpreters/InterpreterDropQuery.cpp:72: DB::InterpreterDropQuery::execute() @ 0x0000000014912b65 9. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88dc9 10. /build/src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x0000000014c8ca7b 11. /build/src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000001686da12 12. /build/src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x0000000016870807 13. /build/src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x0000000016907e99 14. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 15. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 16. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 17. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 18. ? @ 0x00007fbc6213eac3 19. ? @ 0x00007fbc621d0850 2025.07.28 11:56:04.864464 [ 17232 ] {99113dab-039c-4c24-8f13-46608172a8c9} 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. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000000a074fcb 4. /build/src/Interpreters/DatabaseCatalog.cpp:608: DB::DatabaseCatalog::detachDatabase(std::shared_ptr, String const&, bool, bool) @ 0x00000000144f41b9 5. /build/src/Interpreters/InterpreterDropQuery.cpp:482: DB::InterpreterDropQuery::executeToDatabaseImpl(DB::ASTDropQuery const&, std::shared_ptr&, std::vector, DB::UUIDTag>, std::allocator, DB::UUIDTag>>>&) @ 0x00000000149179be 6. /build/src/Interpreters/InterpreterDropQuery.cpp:363: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x0000000014913988 7. /build/src/Interpreters/InterpreterDropQuery.cpp:99: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000014913142 8. /build/src/Interpreters/InterpreterDropQuery.cpp:72: DB::InterpreterDropQuery::execute() @ 0x0000000014912b65 9. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88dc9 10. /build/src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x0000000014c8ca7b 11. /build/src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000001686da12 12. /build/src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x0000000016870807 13. /build/src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x0000000016907e99 14. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 15. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 16. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 17. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 18. ? @ 0x00007fbc6213eac3 19. ? @ 0x00007fbc621d0850 (version 25.3.6.10636.altinitytest (altinity build)) 2025.07.28 11:56:04.864666 [ 3965 ] {} test_13.rmt2 (7f9b740d-015c-470e-8cc6-8ba33be0dc63): auto DB::StorageReplicatedMergeTree::processQueueEntry(ReplicatedMergeTreeQueue::SelectedEntryPtr)::(anonymous class)::operator()(LogEntryPtr &) const: Code: 86. DB::HTTPException: Received error from remote server http://146b4357c08d:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Ftest%2F01165%2Ftest_13%2Frmt%2Freplicas%2F1&part=20250728_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.6.10636.altinitytest (altinity build)) '. (RECEIVED_ERROR_FROM_REMOTE_IO_SERVER), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.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 const&, int&&, String const&, unsigned long&&, String const&) @ 0x000000000feda8d9 4. /build/src/IO/HTTPCommon.cpp:104: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x000000000feda6e2 5. /build/src/IO/HTTPCommon.cpp:93: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x000000000feda537 6. /build/src/IO/ReadWriteBufferFromHTTP.cpp:277: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x000000001184a4c4 7. /build/src/IO/ReadWriteBufferFromHTTP.cpp:285: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x000000001184a615 8. /build/src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x000000001184ae59 9. /build/src/IO/ReadWriteBufferFromHTTP.cpp:472: void std::__function::__policy_invoker::__call_impl[abi:se190107]>(std::__function::__policy_storage const*) @ 0x000000001184cedd 10. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001184858b 11. /build/src/IO/ReadWriteBufferFromHTTP.cpp:465: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x000000001184bf0b 12. /build/src/IO/ReadBuffer.h:60: DB::ReadBuffer::next() @ 0x000000000a148c7b 13. /build/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) @ 0x0000000011849fb2 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]>&)>&, 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&) @ 0x0000000011841980 15. /build/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) @ 0x000000001621208e 16. /build/src/Storages/StorageReplicatedMergeTree.cpp:5228: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl[abi:se190107] const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000015f9a5fe 17. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000015ed8bfd 18. /build/src/Storages/StorageReplicatedMergeTree.cpp:2514: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x0000000015ec9aab 19. /build/src/Storages/StorageReplicatedMergeTree.cpp:2349: DB::StorageReplicatedMergeTree::executeLogEntry(DB::ReplicatedMergeTreeLogEntry&) @ 0x0000000015eba91b 20. /build/src/Storages/StorageReplicatedMergeTree.cpp:3876: bool std::__function::__policy_invoker&)>::__call_impl[abi:se190107])::$_1, bool (std::shared_ptr&)>>(std::__function::__policy_storage const*, std::shared_ptr&) @ 0x0000000015f9837e 21. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000165d6fc3 22. /build/src/Storages/StorageReplicatedMergeTree.cpp:3872: DB::StorageReplicatedMergeTree::processQueueEntry(std::shared_ptr) @ 0x0000000015efc18a 23. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001624c1b2 24. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000162f9c70 25. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x00000000162fa55a 26. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc6653 27. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000000fccc4c3 28. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc3d92 29. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fcca080 30. ? @ 0x00007fbc6213eac3 31. ? @ 0x00007fbc621d0850 (version 25.3.6.10636.altinitytest (altinity build)) 2025.07.28 11:56:05.343809 [ 4446 ] {2310f110-bdaf-4292-a7e5-3ab66e63f142} executeQuery: Code: 507. DB::Exception: Sharding key modulo(sub_key, 2) is not used. (UNABLE_TO_SKIP_UNUSED_SHARDS) (version 25.3.6.10636.altinitytest (altinity build)) (from [::ffff:127.0.0.1]:38524) (comment: 01071_force_optimize_skip_unused_shards.sql) (query 34, line 45) (in query: SELECT `__table1`.`key` AS `key`, `__table1`.`sub_key` AS `sub_key` FROM `test_cs3g75le`.`dist2_layer_01071` AS `__table1` WHERE `__table1`.`key` = 1), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000a9b78ab 4. /build/src/Storages/StorageDistributed.cpp:1559: DB::StorageDistributed::getOptimizedCluster(std::shared_ptr, std::shared_ptr const&, DB::SelectQueryInfo const&, std::shared_ptr const&) const @ 0x0000000015d6083b 5. /build/src/Storages/StorageDistributed.cpp:457: DB::StorageDistributed::getQueryProcessingStage(std::shared_ptr, DB::QueryProcessingStage::Enum, std::shared_ptr const&, DB::SelectQueryInfo&) const @ 0x0000000015d5f50d 6. /build/src/Planner/PlannerJoinTree.cpp:921: DB::(anonymous namespace)::buildQueryPlanForTableExpression(std::shared_ptr, std::shared_ptr const&, DB::SelectQueryInfo const&, DB::SelectQueryOptions const&, std::shared_ptr&, bool, bool) @ 0x0000000014996f1b 7. /build/src/Planner/PlannerJoinTree.cpp:2252: DB::buildJoinTreeQueryPlan(std::shared_ptr const&, DB::SelectQueryInfo const&, DB::SelectQueryOptions&, std::unordered_set, std::equal_to, std::allocator> const&, std::shared_ptr&) @ 0x000000001498e109 8. /build/src/Planner/Planner.cpp:1553: DB::Planner::buildPlanForQueryNode() @ 0x0000000014979dae 9. /build/src/Planner/Planner.cpp:1308: DB::Planner::buildQueryPlanIfNeeded() @ 0x000000001497685c 10. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:255: DB::InterpreterSelectQueryAnalyzer::getQueryPlan() @ 0x000000001497476d 11. /build/src/Interpreters/executeQuery.cpp:1405: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88806 12. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 13. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 14. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 15. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 16. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 17. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 18. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 19. ? @ 0x00007fbc6213eac3 20. ? @ 0x00007fbc621d0850 2025.07.28 11:56:05.347859 [ 4446 ] {} TCPHandler: Code: 507. DB::Exception: Sharding key modulo(sub_key, 2) is not used. (UNABLE_TO_SKIP_UNUSED_SHARDS), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000a9b78ab 4. /build/src/Storages/StorageDistributed.cpp:1559: DB::StorageDistributed::getOptimizedCluster(std::shared_ptr, std::shared_ptr const&, DB::SelectQueryInfo const&, std::shared_ptr const&) const @ 0x0000000015d6083b 5. /build/src/Storages/StorageDistributed.cpp:457: DB::StorageDistributed::getQueryProcessingStage(std::shared_ptr, DB::QueryProcessingStage::Enum, std::shared_ptr const&, DB::SelectQueryInfo&) const @ 0x0000000015d5f50d 6. /build/src/Planner/PlannerJoinTree.cpp:921: DB::(anonymous namespace)::buildQueryPlanForTableExpression(std::shared_ptr, std::shared_ptr const&, DB::SelectQueryInfo const&, DB::SelectQueryOptions const&, std::shared_ptr&, bool, bool) @ 0x0000000014996f1b 7. /build/src/Planner/PlannerJoinTree.cpp:2252: DB::buildJoinTreeQueryPlan(std::shared_ptr const&, DB::SelectQueryInfo const&, DB::SelectQueryOptions&, std::unordered_set, std::equal_to, std::allocator> const&, std::shared_ptr&) @ 0x000000001498e109 8. /build/src/Planner/Planner.cpp:1553: DB::Planner::buildPlanForQueryNode() @ 0x0000000014979dae 9. /build/src/Planner/Planner.cpp:1308: DB::Planner::buildQueryPlanIfNeeded() @ 0x000000001497685c 10. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:255: DB::InterpreterSelectQueryAnalyzer::getQueryPlan() @ 0x000000001497476d 11. /build/src/Interpreters/executeQuery.cpp:1405: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88806 12. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 13. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 14. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 15. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 16. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 17. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 18. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 19. ? @ 0x00007fbc6213eac3 20. ? @ 0x00007fbc621d0850 2025.07.28 11:56:05.353873 [ 17207 ] {d79cee17-2c4c-4ec4-8a2e-be62268903a0} executeQuery: Code: 507. DB::Exception: Received from 127.0.0.2:9000. DB::Exception: Sharding key modulo(sub_key, 2) is not used. Stack trace: 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000a9b78ab 4. /build/src/Storages/StorageDistributed.cpp:1559: DB::StorageDistributed::getOptimizedCluster(std::shared_ptr, std::shared_ptr const&, DB::SelectQueryInfo const&, std::shared_ptr const&) const @ 0x0000000015d6083b 5. /build/src/Storages/StorageDistributed.cpp:457: DB::StorageDistributed::getQueryProcessingStage(std::shared_ptr, DB::QueryProcessingStage::Enum, std::shared_ptr const&, DB::SelectQueryInfo&) const @ 0x0000000015d5f50d 6. /build/src/Planner/PlannerJoinTree.cpp:921: DB::(anonymous namespace)::buildQueryPlanForTableExpression(std::shared_ptr, std::shared_ptr const&, DB::SelectQueryInfo const&, DB::SelectQueryOptions const&, std::shared_ptr&, bool, bool) @ 0x0000000014996f1b 7. /build/src/Planner/PlannerJoinTree.cpp:2252: DB::buildJoinTreeQueryPlan(std::shared_ptr const&, DB::SelectQueryInfo const&, DB::SelectQueryOptions&, std::unordered_set, std::equal_to, std::allocator> const&, std::shared_ptr&) @ 0x000000001498e109 8. /build/src/Planner/Planner.cpp:1553: DB::Planner::buildPlanForQueryNode() @ 0x0000000014979dae 9. /build/src/Planner/Planner.cpp:1308: DB::Planner::buildQueryPlanIfNeeded() @ 0x000000001497685c 10. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:255: DB::InterpreterSelectQueryAnalyzer::getQueryPlan() @ 0x000000001497476d 11. /build/src/Interpreters/executeQuery.cpp:1405: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88806 12. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 13. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 14. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 15. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 16. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 17. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 18. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 19. ? @ 0x00007fbc6213eac3 20. ? @ 0x00007fbc621d0850 : While executing Remote. (UNABLE_TO_SKIP_UNUSED_SHARDS) (version 25.3.6.10636.altinitytest (altinity build)) (from [::1]:60888) (comment: 01071_force_optimize_skip_unused_shards.sql) (query 34, line 45) (in query: select * from dist2_01071 where key = 1;), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:111: DB::readException(DB::ReadBuffer&, String const&, bool) @ 0x000000000fc6e157 3. /build/src/Client/Connection.cpp:1445: DB::Connection::receiveException() const @ 0x00000000167d4127 4. /build/src/Client/Connection.cpp:1274: DB::Connection::receivePacket() @ 0x00000000167db312 5. /build/src/Client/PacketReceiver.cpp:66: DB::PacketReceiver::Task::run(std::function, std::function) @ 0x0000000016819393 6. /build/src/Common/AsyncTaskExecutor.cpp:89: DB::AsyncTaskExecutor::Routine::operator()(std::function) @ 0x0000000013bd1892 7. /build/src/Common/Fiber.h:76: boost::context::detail::fiber_record>::run(void*) @ 0x0000000013bd16fa 8. /build/contrib/boost/boost/context/fiber_fcontext.hpp:97: void boost::context::detail::fiber_entry>>(boost::context::detail::transfer_t) @ 0x0000000013bd1621 2025.07.28 11:56:05.357388 [ 17207 ] {} TCPHandler: Code: 507. DB::Exception: Received from 127.0.0.2:9000. DB::Exception: Sharding key modulo(sub_key, 2) is not used. Stack trace: 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000a9b78ab 4. /build/src/Storages/StorageDistributed.cpp:1559: DB::StorageDistributed::getOptimizedCluster(std::shared_ptr, std::shared_ptr const&, DB::SelectQueryInfo const&, std::shared_ptr const&) const @ 0x0000000015d6083b 5. /build/src/Storages/StorageDistributed.cpp:457: DB::StorageDistributed::getQueryProcessingStage(std::shared_ptr, DB::QueryProcessingStage::Enum, std::shared_ptr const&, DB::SelectQueryInfo&) const @ 0x0000000015d5f50d 6. /build/src/Planner/PlannerJoinTree.cpp:921: DB::(anonymous namespace)::buildQueryPlanForTableExpression(std::shared_ptr, std::shared_ptr const&, DB::SelectQueryInfo const&, DB::SelectQueryOptions const&, std::shared_ptr&, bool, bool) @ 0x0000000014996f1b 7. /build/src/Planner/PlannerJoinTree.cpp:2252: DB::buildJoinTreeQueryPlan(std::shared_ptr const&, DB::SelectQueryInfo const&, DB::SelectQueryOptions&, std::unordered_set, std::equal_to, std::allocator> const&, std::shared_ptr&) @ 0x000000001498e109 8. /build/src/Planner/Planner.cpp:1553: DB::Planner::buildPlanForQueryNode() @ 0x0000000014979dae 9. /build/src/Planner/Planner.cpp:1308: DB::Planner::buildQueryPlanIfNeeded() @ 0x000000001497685c 10. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:255: DB::InterpreterSelectQueryAnalyzer::getQueryPlan() @ 0x000000001497476d 11. /build/src/Interpreters/executeQuery.cpp:1405: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88806 12. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 13. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 14. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 15. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 16. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 17. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 18. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 19. ? @ 0x00007fbc6213eac3 20. ? @ 0x00007fbc621d0850 : While executing Remote. (UNABLE_TO_SKIP_UNUSED_SHARDS), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:111: DB::readException(DB::ReadBuffer&, String const&, bool) @ 0x000000000fc6e157 3. /build/src/Client/Connection.cpp:1445: DB::Connection::receiveException() const @ 0x00000000167d4127 4. /build/src/Client/Connection.cpp:1274: DB::Connection::receivePacket() @ 0x00000000167db312 5. /build/src/Client/PacketReceiver.cpp:66: DB::PacketReceiver::Task::run(std::function, std::function) @ 0x0000000016819393 6. /build/src/Common/AsyncTaskExecutor.cpp:89: DB::AsyncTaskExecutor::Routine::operator()(std::function) @ 0x0000000013bd1892 7. /build/src/Common/Fiber.h:76: boost::context::detail::fiber_record>::run(void*) @ 0x0000000013bd16fa 8. /build/contrib/boost/boost/context/fiber_fcontext.hpp:97: void boost::context::detail::fiber_entry>>(boost::context::detail::transfer_t) @ 0x0000000013bd1621 Job's origin stack trace: 0. /build/src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000000fc33b84 1. /build/src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000000fcc2ea7 2. /build/src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fcc535c 3. /build/src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000000fcc584d 4. /build/src/Common/ThreadPool.h:279: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x00000000169bf193 5. /build/src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x00000000169bf518 6. /build/src/Server/TCPHandler.cpp:1237: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x00000000168f1525 7. /build/src/Server/TCPHandler.cpp:678: DB::TCPHandler::runImpl() @ 0x00000000168e68e5 8. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 9. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 10. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 11. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 12. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 13. ? @ 0x00007fbc6213eac3 14. ? @ 0x00007fbc621d0850 2025.07.28 11:56:05.581461 [ 3970 ] {} test_13.rmt2 (7f9b740d-015c-470e-8cc6-8ba33be0dc63): auto DB::StorageReplicatedMergeTree::processQueueEntry(ReplicatedMergeTreeQueue::SelectedEntryPtr)::(anonymous class)::operator()(LogEntryPtr &) const: Code: 86. DB::HTTPException: Received error from remote server http://146b4357c08d:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Ftest%2F01165%2Ftest_13%2Frmt%2Freplicas%2F1&part=20250728_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.6.10636.altinitytest (altinity build)) '. (RECEIVED_ERROR_FROM_REMOTE_IO_SERVER), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.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 const&, int&&, String const&, unsigned long&&, String const&) @ 0x000000000feda8d9 4. /build/src/IO/HTTPCommon.cpp:104: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x000000000feda6e2 5. /build/src/IO/HTTPCommon.cpp:93: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x000000000feda537 6. /build/src/IO/ReadWriteBufferFromHTTP.cpp:277: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x000000001184a4c4 7. /build/src/IO/ReadWriteBufferFromHTTP.cpp:285: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x000000001184a615 8. /build/src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x000000001184ae59 9. /build/src/IO/ReadWriteBufferFromHTTP.cpp:472: void std::__function::__policy_invoker::__call_impl[abi:se190107]>(std::__function::__policy_storage const*) @ 0x000000001184cedd 10. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001184858b 11. /build/src/IO/ReadWriteBufferFromHTTP.cpp:465: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x000000001184bf0b 12. /build/src/IO/ReadBuffer.h:60: DB::ReadBuffer::next() @ 0x000000000a148c7b 13. /build/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) @ 0x0000000011849fb2 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]>&)>&, 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&) @ 0x0000000011841980 15. /build/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) @ 0x000000001621208e 16. /build/src/Storages/StorageReplicatedMergeTree.cpp:5228: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl[abi:se190107] const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000015f9a5fe 17. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000015ed8bfd 18. /build/src/Storages/StorageReplicatedMergeTree.cpp:2514: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x0000000015ec9aab 19. /build/src/Storages/StorageReplicatedMergeTree.cpp:2349: DB::StorageReplicatedMergeTree::executeLogEntry(DB::ReplicatedMergeTreeLogEntry&) @ 0x0000000015eba91b 20. /build/src/Storages/StorageReplicatedMergeTree.cpp:3876: bool std::__function::__policy_invoker&)>::__call_impl[abi:se190107])::$_1, bool (std::shared_ptr&)>>(std::__function::__policy_storage const*, std::shared_ptr&) @ 0x0000000015f9837e 21. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000165d6fc3 22. /build/src/Storages/StorageReplicatedMergeTree.cpp:3872: DB::StorageReplicatedMergeTree::processQueueEntry(std::shared_ptr) @ 0x0000000015efc18a 23. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001624c1b2 24. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000162f9c70 25. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x00000000162fa55a 26. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc6653 27. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000000fccc4c3 28. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc3d92 29. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fcca080 30. ? @ 0x00007fbc6213eac3 31. ? @ 0x00007fbc621d0850 (version 25.3.6.10636.altinitytest (altinity build)) 2025.07.28 11:56:05.865988 [ 17611 ] {f3e20d4d-0f71-4037-930b-30fde457b4c1} executeQuery: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=0, jobs=0). (CANNOT_SCHEDULE_TASK) (version 25.3.6.10636.altinitytest (altinity build)) (from [::1]:32780) (comment: 02966_topk_counts_approx_count_sum.sql) (query 1, line 1) (in query: WITH arraySlice(arrayReverseSort(x -> (x.2, x.1), arrayZip(untuple(sumMap(([k], [1]))))), 1, 5) AS topKExact, arraySlice(arrayReverseSort(x -> (x.2, x.1), arrayZip(untuple(sumMap(([k], [w]))))), 1, 5) AS topKWeightedExact SELECT topKExact, topKWeightedExact, topK(3, 2, 'counts')(k) AS topK_counts, topKWeighted(3, 2, 'counts')(k, w) AS topKWeighted_counts, approx_top_count(3, 6)(k) AS approx_top_count, approx_top_k(3, 6)(k) AS approx_top_k, approx_top_sum(3, 6)(k, w) AS approx_top_sum FROM ( SELECT concat(countDigits(number * number), '_', intDiv((number % 10), 7)) AS k, number AS w FROM numbers(1000) );), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000fccaeeb 4. /build/src/Common/ThreadPool.cpp:275: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000fccc813 5. /build/src/Common/ThreadPool.cpp:323: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fcc7bbc 6. /build/src/Common/ThreadPool.cpp:494: ThreadPoolImpl>::scheduleOrThrowOnError(std::function, Priority) @ 0x000000000fcc7a0e 7. /build/src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::spawnThreadsImpl() @ 0x00000000169b2c0c 8. /build/src/Processors/Executors/PipelineExecutor.cpp:394: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x00000000169b0ba7 9. /build/src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x00000000169b03f4 10. /build/src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:se190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169bfeab 11. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc3d92 12. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fcca080 13. ? @ 0x00007fbc6213eac3 14. ? @ 0x00007fbc621d0850 2025.07.28 11:56:05.939976 [ 17611 ] {} 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. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000fccaeeb 4. /build/src/Common/ThreadPool.cpp:275: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000fccc813 5. /build/src/Common/ThreadPool.cpp:323: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fcc7bbc 6. /build/src/Common/ThreadPool.cpp:494: ThreadPoolImpl>::scheduleOrThrowOnError(std::function, Priority) @ 0x000000000fcc7a0e 7. /build/src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::spawnThreadsImpl() @ 0x00000000169b2c0c 8. /build/src/Processors/Executors/PipelineExecutor.cpp:394: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x00000000169b0ba7 9. /build/src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x00000000169b03f4 10. /build/src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:se190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169bfeab 11. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc3d92 12. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fcca080 13. ? @ 0x00007fbc6213eac3 14. ? @ 0x00007fbc621d0850 Job's origin stack trace: 0. /build/src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000000fc33b84 1. /build/src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000000fcc2ea7 2. /build/src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fcc535c 3. /build/src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000000fcc584d 4. /build/src/Common/ThreadPool.h:279: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x00000000169bf193 5. /build/src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x00000000169bf518 6. /build/src/Server/TCPHandler.cpp:1237: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x00000000168f1525 7. /build/src/Server/TCPHandler.cpp:678: DB::TCPHandler::runImpl() @ 0x00000000168e68e5 8. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 9. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 10. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 11. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 12. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 13. ? @ 0x00007fbc6213eac3 14. ? @ 0x00007fbc621d0850 2025.07.28 11:56:05.976194 [ 3961 ] {} test_13.rmt2 (7f9b740d-015c-470e-8cc6-8ba33be0dc63): auto DB::StorageReplicatedMergeTree::processQueueEntry(ReplicatedMergeTreeQueue::SelectedEntryPtr)::(anonymous class)::operator()(LogEntryPtr &) const: Code: 86. DB::HTTPException: Received error from remote server http://146b4357c08d:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Ftest%2F01165%2Ftest_13%2Frmt%2Freplicas%2F1&part=20250728_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.6.10636.altinitytest (altinity build)) '. (RECEIVED_ERROR_FROM_REMOTE_IO_SERVER), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.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 const&, int&&, String const&, unsigned long&&, String const&) @ 0x000000000feda8d9 4. /build/src/IO/HTTPCommon.cpp:104: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x000000000feda6e2 5. /build/src/IO/HTTPCommon.cpp:93: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x000000000feda537 6. /build/src/IO/ReadWriteBufferFromHTTP.cpp:277: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x000000001184a4c4 7. /build/src/IO/ReadWriteBufferFromHTTP.cpp:285: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x000000001184a615 8. /build/src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x000000001184ae59 9. /build/src/IO/ReadWriteBufferFromHTTP.cpp:472: void std::__function::__policy_invoker::__call_impl[abi:se190107]>(std::__function::__policy_storage const*) @ 0x000000001184cedd 10. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001184858b 11. /build/src/IO/ReadWriteBufferFromHTTP.cpp:465: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x000000001184bf0b 12. /build/src/IO/ReadBuffer.h:60: DB::ReadBuffer::next() @ 0x000000000a148c7b 13. /build/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) @ 0x0000000011849fb2 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]>&)>&, 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&) @ 0x0000000011841980 15. /build/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) @ 0x000000001621208e 16. /build/src/Storages/StorageReplicatedMergeTree.cpp:5228: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl[abi:se190107] const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000015f9a5fe 17. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000015ed8bfd 18. /build/src/Storages/StorageReplicatedMergeTree.cpp:2514: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x0000000015ec9aab 19. /build/src/Storages/StorageReplicatedMergeTree.cpp:2349: DB::StorageReplicatedMergeTree::executeLogEntry(DB::ReplicatedMergeTreeLogEntry&) @ 0x0000000015eba91b 20. /build/src/Storages/StorageReplicatedMergeTree.cpp:3876: bool std::__function::__policy_invoker&)>::__call_impl[abi:se190107])::$_1, bool (std::shared_ptr&)>>(std::__function::__policy_storage const*, std::shared_ptr&) @ 0x0000000015f9837e 21. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000165d6fc3 22. /build/src/Storages/StorageReplicatedMergeTree.cpp:3872: DB::StorageReplicatedMergeTree::processQueueEntry(std::shared_ptr) @ 0x0000000015efc18a 23. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001624c1b2 24. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000162f9c70 25. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x00000000162fa55a 26. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc6653 27. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000000fccc4c3 28. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc3d92 29. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fcca080 30. ? @ 0x00007fbc6213eac3 31. ? @ 0x00007fbc621d0850 (version 25.3.6.10636.altinitytest (altinity build)) 2025.07.28 11:56:06.080685 [ 17232 ] {40abf419-fe76-475b-8901-3de64d7f3619} 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.6.10636.altinitytest (altinity build)) (from [::1]:32774) (comment: 00423_storage_log_single_thread.sql) (query 5, line 7) (in query: DETACH TABLE log;), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000000a074fcb 4. /build/src/Databases/DatabaseReplicated.cpp:1108: DB::DatabaseReplicated::checkQueryValid(std::shared_ptr const&, std::shared_ptr) const @ 0x0000000013d9ef48 5. /build/src/Databases/DatabaseReplicated.cpp:1130: DB::DatabaseReplicated::tryEnqueueReplicatedDDL(std::shared_ptr const&, std::shared_ptr, DB::QueryFlags) @ 0x0000000013d9f10b 6. /build/src/Interpreters/InterpreterDropQuery.cpp:226: DB::InterpreterDropQuery::executeToTableImpl(std::shared_ptr const&, DB::ASTDropQuery&, std::shared_ptr&, StrongTypedef, DB::UUIDTag>&) @ 0x0000000014914ed7 7. /build/src/Interpreters/InterpreterDropQuery.cpp:118: DB::InterpreterDropQuery::executeToTable(DB::ASTDropQuery&) @ 0x00000000149137b4 8. /build/src/Interpreters/InterpreterDropQuery.cpp:91: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000014912f07 9. /build/src/Interpreters/InterpreterDropQuery.cpp:72: DB::InterpreterDropQuery::execute() @ 0x0000000014912b65 10. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88dc9 11. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 12. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 13. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 14. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 15. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 16. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 17. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 18. ? @ 0x00007fbc6213eac3 19. ? @ 0x00007fbc621d0850 2025.07.28 11:56:06.098862 [ 17232 ] {} 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. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000000a074fcb 4. /build/src/Databases/DatabaseReplicated.cpp:1108: DB::DatabaseReplicated::checkQueryValid(std::shared_ptr const&, std::shared_ptr) const @ 0x0000000013d9ef48 5. /build/src/Databases/DatabaseReplicated.cpp:1130: DB::DatabaseReplicated::tryEnqueueReplicatedDDL(std::shared_ptr const&, std::shared_ptr, DB::QueryFlags) @ 0x0000000013d9f10b 6. /build/src/Interpreters/InterpreterDropQuery.cpp:226: DB::InterpreterDropQuery::executeToTableImpl(std::shared_ptr const&, DB::ASTDropQuery&, std::shared_ptr&, StrongTypedef, DB::UUIDTag>&) @ 0x0000000014914ed7 7. /build/src/Interpreters/InterpreterDropQuery.cpp:118: DB::InterpreterDropQuery::executeToTable(DB::ASTDropQuery&) @ 0x00000000149137b4 8. /build/src/Interpreters/InterpreterDropQuery.cpp:91: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000014912f07 9. /build/src/Interpreters/InterpreterDropQuery.cpp:72: DB::InterpreterDropQuery::execute() @ 0x0000000014912b65 10. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88dc9 11. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 12. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 13. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 14. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 15. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 16. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 17. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 18. ? @ 0x00007fbc6213eac3 19. ? @ 0x00007fbc621d0850 2025.07.28 11:56:06.767767 [ 3971 ] {} test_13.rmt2 (7f9b740d-015c-470e-8cc6-8ba33be0dc63): auto DB::StorageReplicatedMergeTree::processQueueEntry(ReplicatedMergeTreeQueue::SelectedEntryPtr)::(anonymous class)::operator()(LogEntryPtr &) const: Code: 86. DB::HTTPException: Received error from remote server http://146b4357c08d:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Ftest%2F01165%2Ftest_13%2Frmt%2Freplicas%2F1&part=20250728_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.6.10636.altinitytest (altinity build)) '. (RECEIVED_ERROR_FROM_REMOTE_IO_SERVER), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.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 const&, int&&, String const&, unsigned long&&, String const&) @ 0x000000000feda8d9 4. /build/src/IO/HTTPCommon.cpp:104: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x000000000feda6e2 5. /build/src/IO/HTTPCommon.cpp:93: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x000000000feda537 6. /build/src/IO/ReadWriteBufferFromHTTP.cpp:277: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x000000001184a4c4 7. /build/src/IO/ReadWriteBufferFromHTTP.cpp:285: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x000000001184a615 8. /build/src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x000000001184ae59 9. /build/src/IO/ReadWriteBufferFromHTTP.cpp:472: void std::__function::__policy_invoker::__call_impl[abi:se190107]>(std::__function::__policy_storage const*) @ 0x000000001184cedd 10. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001184858b 11. /build/src/IO/ReadWriteBufferFromHTTP.cpp:465: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x000000001184bf0b 12. /build/src/IO/ReadBuffer.h:60: DB::ReadBuffer::next() @ 0x000000000a148c7b 13. /build/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) @ 0x0000000011849fb2 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]>&)>&, 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&) @ 0x0000000011841980 15. /build/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) @ 0x000000001621208e 16. /build/src/Storages/StorageReplicatedMergeTree.cpp:5228: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl[abi:se190107] const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000015f9a5fe 17. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000015ed8bfd 18. /build/src/Storages/StorageReplicatedMergeTree.cpp:2514: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x0000000015ec9aab 19. /build/src/Storages/StorageReplicatedMergeTree.cpp:2349: DB::StorageReplicatedMergeTree::executeLogEntry(DB::ReplicatedMergeTreeLogEntry&) @ 0x0000000015eba91b 20. /build/src/Storages/StorageReplicatedMergeTree.cpp:3876: bool std::__function::__policy_invoker&)>::__call_impl[abi:se190107])::$_1, bool (std::shared_ptr&)>>(std::__function::__policy_storage const*, std::shared_ptr&) @ 0x0000000015f9837e 21. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000165d6fc3 22. /build/src/Storages/StorageReplicatedMergeTree.cpp:3872: DB::StorageReplicatedMergeTree::processQueueEntry(std::shared_ptr) @ 0x0000000015efc18a 23. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001624c1b2 24. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000162f9c70 25. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x00000000162fa55a 26. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc6653 27. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000000fccc4c3 28. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc3d92 29. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fcca080 30. ? @ 0x00007fbc6213eac3 31. ? @ 0x00007fbc621d0850 (version 25.3.6.10636.altinitytest (altinity build)) 2025.07.28 11:56:07.486256 [ 3967 ] {} test_13.rmt2 (7f9b740d-015c-470e-8cc6-8ba33be0dc63): auto DB::StorageReplicatedMergeTree::processQueueEntry(ReplicatedMergeTreeQueue::SelectedEntryPtr)::(anonymous class)::operator()(LogEntryPtr &) const: Code: 86. DB::HTTPException: Received error from remote server http://146b4357c08d:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Ftest%2F01165%2Ftest_13%2Frmt%2Freplicas%2F1&part=20250728_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.6.10636.altinitytest (altinity build)) '. (RECEIVED_ERROR_FROM_REMOTE_IO_SERVER), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.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 const&, int&&, String const&, unsigned long&&, String const&) @ 0x000000000feda8d9 4. /build/src/IO/HTTPCommon.cpp:104: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x000000000feda6e2 5. /build/src/IO/HTTPCommon.cpp:93: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x000000000feda537 6. /build/src/IO/ReadWriteBufferFromHTTP.cpp:277: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x000000001184a4c4 7. /build/src/IO/ReadWriteBufferFromHTTP.cpp:285: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x000000001184a615 8. /build/src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x000000001184ae59 9. /build/src/IO/ReadWriteBufferFromHTTP.cpp:472: void std::__function::__policy_invoker::__call_impl[abi:se190107]>(std::__function::__policy_storage const*) @ 0x000000001184cedd 10. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001184858b 11. /build/src/IO/ReadWriteBufferFromHTTP.cpp:465: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x000000001184bf0b 12. /build/src/IO/ReadBuffer.h:60: DB::ReadBuffer::next() @ 0x000000000a148c7b 13. /build/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) @ 0x0000000011849fb2 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]>&)>&, 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&) @ 0x0000000011841980 15. /build/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) @ 0x000000001621208e 16. /build/src/Storages/StorageReplicatedMergeTree.cpp:5228: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl[abi:se190107] const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000015f9a5fe 17. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000015ed8bfd 18. /build/src/Storages/StorageReplicatedMergeTree.cpp:2514: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x0000000015ec9aab 19. /build/src/Storages/StorageReplicatedMergeTree.cpp:2349: DB::StorageReplicatedMergeTree::executeLogEntry(DB::ReplicatedMergeTreeLogEntry&) @ 0x0000000015eba91b 20. /build/src/Storages/StorageReplicatedMergeTree.cpp:3876: bool std::__function::__policy_invoker&)>::__call_impl[abi:se190107])::$_1, bool (std::shared_ptr&)>>(std::__function::__policy_storage const*, std::shared_ptr&) @ 0x0000000015f9837e 21. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000165d6fc3 22. /build/src/Storages/StorageReplicatedMergeTree.cpp:3872: DB::StorageReplicatedMergeTree::processQueueEntry(std::shared_ptr) @ 0x0000000015efc18a 23. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001624c1b2 24. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000162f9c70 25. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x00000000162fa55a 26. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc6653 27. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000000fccc4c3 28. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc3d92 29. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fcca080 30. ? @ 0x00007fbc6213eac3 31. ? @ 0x00007fbc621d0850 (version 25.3.6.10636.altinitytest (altinity build)) 2025.07.28 11:56:07.814514 [ 4963 ] {} 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. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x000000000c25bc4b 4. /build/src/Access/SettingsConstraints.cpp:343: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000138596e3 5. /build/src/Access/SettingsConstraints.cpp:300: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000013858faf 6. /build/src/Access/SettingsConstraints.cpp:209: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x00000000138592b8 7. /build/src/Interpreters/Context.cpp:2690: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000014436134 8. /build/src/Interpreters/Context.cpp:2729: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x000000001443662b 9. /build/src/Server/TCPHandler.cpp:2158: DB::TCPHandler::processQuery(std::optional&) @ 0x00000000168f61df 10. /build/src/Server/TCPHandler.cpp:918: DB::TCPHandler::receivePacketsExpectQuery(std::optional&) @ 0x00000000168ef965 11. /build/src/Server/TCPHandler.cpp:491: DB::TCPHandler::runImpl() @ 0x00000000168e5eb4 12. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 13. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 14. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 16. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 17. ? @ 0x00007fbc6213eac3 18. ? @ 0x00007fbc621d0850 2025.07.28 11:56:07.815487 [ 4963 ] {} 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. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000000a074fcb 4. /build/src/Server/TCPHandler.cpp:897: DB::TCPHandler::receivePacketsExpectQuery(std::optional&) @ 0x00000000168efa89 5. /build/src/Server/TCPHandler.cpp:491: DB::TCPHandler::runImpl() @ 0x00000000168e5eb4 6. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 7. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 8. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 9. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 10. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 11. ? @ 0x00007fbc6213eac3 12. ? @ 0x00007fbc621d0850 2025.07.28 11:56:07.880539 [ 3965 ] {} test_13.rmt2 (7f9b740d-015c-470e-8cc6-8ba33be0dc63): auto DB::StorageReplicatedMergeTree::processQueueEntry(ReplicatedMergeTreeQueue::SelectedEntryPtr)::(anonymous class)::operator()(LogEntryPtr &) const: Code: 86. DB::HTTPException: Received error from remote server http://146b4357c08d:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Ftest%2F01165%2Ftest_13%2Frmt%2Freplicas%2F1&part=20250728_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.6.10636.altinitytest (altinity build)) '. (RECEIVED_ERROR_FROM_REMOTE_IO_SERVER), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.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 const&, int&&, String const&, unsigned long&&, String const&) @ 0x000000000feda8d9 4. /build/src/IO/HTTPCommon.cpp:104: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x000000000feda6e2 5. /build/src/IO/HTTPCommon.cpp:93: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x000000000feda537 6. /build/src/IO/ReadWriteBufferFromHTTP.cpp:277: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x000000001184a4c4 7. /build/src/IO/ReadWriteBufferFromHTTP.cpp:285: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x000000001184a615 8. /build/src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x000000001184ae59 9. /build/src/IO/ReadWriteBufferFromHTTP.cpp:472: void std::__function::__policy_invoker::__call_impl[abi:se190107]>(std::__function::__policy_storage const*) @ 0x000000001184cedd 10. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001184858b 11. /build/src/IO/ReadWriteBufferFromHTTP.cpp:465: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x000000001184bf0b 12. /build/src/IO/ReadBuffer.h:60: DB::ReadBuffer::next() @ 0x000000000a148c7b 13. /build/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) @ 0x0000000011849fb2 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]>&)>&, 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&) @ 0x0000000011841980 15. /build/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) @ 0x000000001621208e 16. /build/src/Storages/StorageReplicatedMergeTree.cpp:5228: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl[abi:se190107] const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000015f9a5fe 17. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000015ed8bfd 18. /build/src/Storages/StorageReplicatedMergeTree.cpp:2514: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x0000000015ec9aab 19. /build/src/Storages/StorageReplicatedMergeTree.cpp:2349: DB::StorageReplicatedMergeTree::executeLogEntry(DB::ReplicatedMergeTreeLogEntry&) @ 0x0000000015eba91b 20. /build/src/Storages/StorageReplicatedMergeTree.cpp:3876: bool std::__function::__policy_invoker&)>::__call_impl[abi:se190107])::$_1, bool (std::shared_ptr&)>>(std::__function::__policy_storage const*, std::shared_ptr&) @ 0x0000000015f9837e 21. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000165d6fc3 22. /build/src/Storages/StorageReplicatedMergeTree.cpp:3872: DB::StorageReplicatedMergeTree::processQueueEntry(std::shared_ptr) @ 0x0000000015efc18a 23. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001624c1b2 24. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000162f9c70 25. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x00000000162fa55a 26. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc6653 27. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000000fccc4c3 28. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc3d92 29. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fcca080 30. ? @ 0x00007fbc6213eac3 31. ? @ 0x00007fbc621d0850 (version 25.3.6.10636.altinitytest (altinity build)) 2025.07.28 11:56:07.998541 [ 4963 ] {bfdfac05-8cc6-4ffa-a024-c8b6c9bc31e2} executeQuery: Code: 60. DB::Exception: Table test_8okf61mm.ghdata does not exist. Maybe you meant test_1.data?. (UNKNOWN_TABLE) (version 25.3.6.10636.altinitytest (altinity build)) (from [::1]:32878) (comment: 03272_ghdata_object_to_json_alter_shared_data.sh) (query 1, line 1) (in query: INSERT INTO ghdata FORMAT JSONAsObject), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/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&&) @ 0x000000000a1011eb 4. /build/src/Databases/IDatabase.cpp:42: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x0000000013dd57aa 5. /build/src/Interpreters/DatabaseCatalog.cpp:442: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x00000000144f0869 6. /build/src/Interpreters/DatabaseCatalog.cpp:976: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x00000000144f6c88 7. /build/src/Interpreters/InterpreterInsertQuery.cpp:169: DB::InterpreterInsertQuery::getTable(DB::ASTInsertQuery&) @ 0x000000001492bf04 8. /build/src/Interpreters/InterpreterInsertQuery.cpp:829: DB::InterpreterInsertQuery::execute() @ 0x0000000014933938 9. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88dc9 10. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 11. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 12. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 13. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 14. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 16. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 17. ? @ 0x00007fbc6213eac3 18. ? @ 0x00007fbc621d0850 2025.07.28 11:56:08.014245 [ 4963 ] {} TCPHandler: Code: 60. DB::Exception: Table test_8okf61mm.ghdata does not exist. Maybe you meant test_1.data?. (UNKNOWN_TABLE), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/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&&) @ 0x000000000a1011eb 4. /build/src/Databases/IDatabase.cpp:42: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x0000000013dd57aa 5. /build/src/Interpreters/DatabaseCatalog.cpp:442: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x00000000144f0869 6. /build/src/Interpreters/DatabaseCatalog.cpp:976: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x00000000144f6c88 7. /build/src/Interpreters/InterpreterInsertQuery.cpp:169: DB::InterpreterInsertQuery::getTable(DB::ASTInsertQuery&) @ 0x000000001492bf04 8. /build/src/Interpreters/InterpreterInsertQuery.cpp:829: DB::InterpreterInsertQuery::execute() @ 0x0000000014933938 9. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88dc9 10. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 11. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 12. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 13. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 14. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 16. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 17. ? @ 0x00007fbc6213eac3 18. ? @ 0x00007fbc621d0850 2025.07.28 11:56:08.080056 [ 3961 ] {} test_13.rmt2 (7f9b740d-015c-470e-8cc6-8ba33be0dc63): auto DB::StorageReplicatedMergeTree::processQueueEntry(ReplicatedMergeTreeQueue::SelectedEntryPtr)::(anonymous class)::operator()(LogEntryPtr &) const: Code: 86. DB::HTTPException: Received error from remote server http://146b4357c08d:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Ftest%2F01165%2Ftest_13%2Frmt%2Freplicas%2F1&part=20250728_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.6.10636.altinitytest (altinity build)) '. (RECEIVED_ERROR_FROM_REMOTE_IO_SERVER), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.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 const&, int&&, String const&, unsigned long&&, String const&) @ 0x000000000feda8d9 4. /build/src/IO/HTTPCommon.cpp:104: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x000000000feda6e2 5. /build/src/IO/HTTPCommon.cpp:93: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x000000000feda537 6. /build/src/IO/ReadWriteBufferFromHTTP.cpp:277: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x000000001184a4c4 7. /build/src/IO/ReadWriteBufferFromHTTP.cpp:285: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x000000001184a615 8. /build/src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x000000001184ae59 9. /build/src/IO/ReadWriteBufferFromHTTP.cpp:472: void std::__function::__policy_invoker::__call_impl[abi:se190107]>(std::__function::__policy_storage const*) @ 0x000000001184cedd 10. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001184858b 11. /build/src/IO/ReadWriteBufferFromHTTP.cpp:465: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x000000001184bf0b 12. /build/src/IO/ReadBuffer.h:60: DB::ReadBuffer::next() @ 0x000000000a148c7b 13. /build/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) @ 0x0000000011849fb2 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]>&)>&, 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&) @ 0x0000000011841980 15. /build/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) @ 0x000000001621208e 16. /build/src/Storages/StorageReplicatedMergeTree.cpp:5228: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl[abi:se190107] const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000015f9a5fe 17. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000015ed8bfd 18. /build/src/Storages/StorageReplicatedMergeTree.cpp:2514: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x0000000015ec9aab 19. /build/src/Storages/StorageReplicatedMergeTree.cpp:2349: DB::StorageReplicatedMergeTree::executeLogEntry(DB::ReplicatedMergeTreeLogEntry&) @ 0x0000000015eba91b 20. /build/src/Storages/StorageReplicatedMergeTree.cpp:3876: bool std::__function::__policy_invoker&)>::__call_impl[abi:se190107])::$_1, bool (std::shared_ptr&)>>(std::__function::__policy_storage const*, std::shared_ptr&) @ 0x0000000015f9837e 21. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000165d6fc3 22. /build/src/Storages/StorageReplicatedMergeTree.cpp:3872: DB::StorageReplicatedMergeTree::processQueueEntry(std::shared_ptr) @ 0x0000000015efc18a 23. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001624c1b2 24. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000162f9c70 25. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x00000000162fa55a 26. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc6653 27. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000000fccc4c3 28. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc3d92 29. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fcca080 30. ? @ 0x00007fbc6213eac3 31. ? @ 0x00007fbc621d0850 (version 25.3.6.10636.altinitytest (altinity build)) 2025.07.28 11:56:08.225875 [ 4963 ] {5002e77e-50a3-4ee4-a2eb-d7a183e1f16e} executeQuery: Code: 60. DB::Exception: Could not find table: ghdata. (UNKNOWN_TABLE) (version 25.3.6.10636.altinitytest (altinity build)) (from [::1]:32892) (comment: 03272_ghdata_object_to_json_alter_shared_data.sh) (query 1, line 1) (in query: ALTER TABLE ghdata MODIFY column data JSON(max_dynamic_paths=8) SETTINGS mutations_sync=1), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x000000000a080b2b 4. /build/src/Interpreters/InterpreterAlterQuery.cpp:134: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x00000000148df7d9 5. /build/src/Interpreters/InterpreterAlterQuery.cpp:77: DB::InterpreterAlterQuery::execute() @ 0x00000000148dcb0d 6. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88dc9 7. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 8. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 9. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 10. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 11. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 12. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 13. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 14. ? @ 0x00007fbc6213eac3 15. ? @ 0x00007fbc621d0850 2025.07.28 11:56:08.251932 [ 4963 ] {} TCPHandler: Code: 60. DB::Exception: Could not find table: ghdata. (UNKNOWN_TABLE), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x000000000a080b2b 4. /build/src/Interpreters/InterpreterAlterQuery.cpp:134: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x00000000148df7d9 5. /build/src/Interpreters/InterpreterAlterQuery.cpp:77: DB::InterpreterAlterQuery::execute() @ 0x00000000148dcb0d 6. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88dc9 7. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 8. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 9. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 10. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 11. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 12. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 13. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 14. ? @ 0x00007fbc6213eac3 15. ? @ 0x00007fbc621d0850 2025.07.28 11:56:08.412462 [ 4963 ] {e40adcd2-e901-4d6d-b1e6-5123a0acaec9} executeQuery: Code: 60. DB::Exception: Unknown table expression identifier 'ghdata' in scope SELECT count() FROM ghdata WHERE NOT ignore(*). (UNKNOWN_TABLE) (version 25.3.6.10636.altinitytest (altinity build)) (from [::1]:32916) (comment: 03272_ghdata_object_to_json_alter_shared_data.sh) (query 1, line 1) (in query: SELECT count() FROM ghdata WHERE NOT ignore(*)), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x000000000a6a1e2b 4. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:4372: DB::QueryAnalyzer::initializeQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000001404440b 5. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5594: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000140135fb 6. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000140127f9 7. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000014011fce 8. /build/src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000001406ce8a 9. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000014973b42 10. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000001497268d 11. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000014974d24 12. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001492924b 13. /build/src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88641 14. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 15. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 16. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 17. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 18. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 19. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 20. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 21. ? @ 0x00007fbc6213eac3 22. ? @ 0x00007fbc621d0850 2025.07.28 11:56:08.423094 [ 4963 ] {} TCPHandler: Code: 60. DB::Exception: Unknown table expression identifier 'ghdata' in scope SELECT count() FROM ghdata WHERE NOT ignore(*). (UNKNOWN_TABLE), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x000000000a6a1e2b 4. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:4372: DB::QueryAnalyzer::initializeQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000001404440b 5. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5594: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000140135fb 6. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000140127f9 7. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000014011fce 8. /build/src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000001406ce8a 9. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000014973b42 10. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000001497268d 11. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000014974d24 12. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001492924b 13. /build/src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88641 14. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 15. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 16. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 17. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 18. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 19. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 20. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 21. ? @ 0x00007fbc6213eac3 22. ? @ 0x00007fbc621d0850 2025.07.28 11:56:08.612274 [ 3960 ] {} test_13.rmt2 (7f9b740d-015c-470e-8cc6-8ba33be0dc63): auto DB::StorageReplicatedMergeTree::processQueueEntry(ReplicatedMergeTreeQueue::SelectedEntryPtr)::(anonymous class)::operator()(LogEntryPtr &) const: Code: 86. DB::HTTPException: Received error from remote server http://146b4357c08d:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Ftest%2F01165%2Ftest_13%2Frmt%2Freplicas%2F1&part=20250728_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.6.10636.altinitytest (altinity build)) '. (RECEIVED_ERROR_FROM_REMOTE_IO_SERVER), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.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 const&, int&&, String const&, unsigned long&&, String const&) @ 0x000000000feda8d9 4. /build/src/IO/HTTPCommon.cpp:104: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x000000000feda6e2 5. /build/src/IO/HTTPCommon.cpp:93: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x000000000feda537 6. /build/src/IO/ReadWriteBufferFromHTTP.cpp:277: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x000000001184a4c4 7. /build/src/IO/ReadWriteBufferFromHTTP.cpp:285: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x000000001184a615 8. /build/src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x000000001184ae59 9. /build/src/IO/ReadWriteBufferFromHTTP.cpp:472: void std::__function::__policy_invoker::__call_impl[abi:se190107]>(std::__function::__policy_storage const*) @ 0x000000001184cedd 10. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001184858b 11. /build/src/IO/ReadWriteBufferFromHTTP.cpp:465: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x000000001184bf0b 12. /build/src/IO/ReadBuffer.h:60: DB::ReadBuffer::next() @ 0x000000000a148c7b 13. /build/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) @ 0x0000000011849fb2 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]>&)>&, 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&) @ 0x0000000011841980 15. /build/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) @ 0x000000001621208e 16. /build/src/Storages/StorageReplicatedMergeTree.cpp:5228: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl[abi:se190107] const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000015f9a5fe 17. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000015ed8bfd 18. /build/src/Storages/StorageReplicatedMergeTree.cpp:2514: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x0000000015ec9aab 19. /build/src/Storages/StorageReplicatedMergeTree.cpp:2349: DB::StorageReplicatedMergeTree::executeLogEntry(DB::ReplicatedMergeTreeLogEntry&) @ 0x0000000015eba91b 20. /build/src/Storages/StorageReplicatedMergeTree.cpp:3876: bool std::__function::__policy_invoker&)>::__call_impl[abi:se190107])::$_1, bool (std::shared_ptr&)>>(std::__function::__policy_storage const*, std::shared_ptr&) @ 0x0000000015f9837e 21. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000165d6fc3 22. /build/src/Storages/StorageReplicatedMergeTree.cpp:3872: DB::StorageReplicatedMergeTree::processQueueEntry(std::shared_ptr) @ 0x0000000015efc18a 23. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001624c1b2 24. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000162f9c70 25. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x00000000162fa55a 26. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc6653 27. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000000fccc4c3 28. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc3d92 29. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fcca080 30. ? @ 0x00007fbc6213eac3 31. ? @ 0x00007fbc621d0850 (version 25.3.6.10636.altinitytest (altinity build)) 2025.07.28 11:56:08.656137 [ 4963 ] {eaa617aa-76a0-4b4b-8754-53bd94b906c6} executeQuery: Code: 60. DB::Exception: Unknown table expression identifier 'ghdata' in scope SELECT data.repo.name, count() AS stars FROM ghdata WHERE data.type = 'WatchEvent' GROUP BY data.repo.name ORDER BY stars DESC, data.repo.name ASC LIMIT 5. (UNKNOWN_TABLE) (version 25.3.6.10636.altinitytest (altinity build)) (from [::1]:32928) (comment: 03272_ghdata_object_to_json_alter_shared_data.sh) (query 1, line 1) (in query: SELECT data.repo.name, count() AS stars FROM ghdata WHERE data.type = 'WatchEvent' GROUP BY data.repo.name ORDER BY stars DESC, data.repo.name LIMIT 5), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x000000000a6a1e2b 4. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:4372: DB::QueryAnalyzer::initializeQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000001404440b 5. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5594: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000140135fb 6. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000140127f9 7. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000014011fce 8. /build/src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000001406ce8a 9. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000014973b42 10. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000001497268d 11. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000014974d24 12. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001492924b 13. /build/src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88641 14. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 15. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 16. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 17. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 18. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 19. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 20. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 21. ? @ 0x00007fbc6213eac3 22. ? @ 0x00007fbc621d0850 2025.07.28 11:56:08.671996 [ 4963 ] {} TCPHandler: Code: 60. DB::Exception: Unknown table expression identifier 'ghdata' in scope SELECT data.repo.name, count() AS stars FROM ghdata WHERE data.type = 'WatchEvent' GROUP BY data.repo.name ORDER BY stars DESC, data.repo.name ASC LIMIT 5. (UNKNOWN_TABLE), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x000000000a6a1e2b 4. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:4372: DB::QueryAnalyzer::initializeQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000001404440b 5. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5594: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000140135fb 6. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000140127f9 7. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000014011fce 8. /build/src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000001406ce8a 9. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000014973b42 10. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000001497268d 11. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000014974d24 12. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001492924b 13. /build/src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88641 14. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 15. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 16. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 17. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 18. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 19. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 20. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 21. ? @ 0x00007fbc6213eac3 22. ? @ 0x00007fbc621d0850 2025.07.28 11:56:08.945339 [ 4963 ] {c7a86863-3d0a-4b5b-bc48-2261445bf5f1} executeQuery: Code: 60. DB::Exception: Unknown table expression identifier 'ghdata' in scope SELECT data.payload.commits.:`Array(JSON)`.author.name AS name, count() AS c FROM ghdata ARRAY JOIN data.payload.commits.:`Array(JSON)`.author.name GROUP BY name ORDER BY c DESC, name ASC LIMIT 5. (UNKNOWN_TABLE) (version 25.3.6.10636.altinitytest (altinity build)) (from [::1]:32950) (comment: 03272_ghdata_object_to_json_alter_shared_data.sh) (query 1, line 1) (in query: SELECT data.payload.commits[].author.name AS name, count() AS c FROM ghdata ARRAY JOIN data.payload.commits[].author.name GROUP BY name ORDER BY c DESC, name LIMIT 5), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x000000000a6a1e2b 4. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:4372: DB::QueryAnalyzer::initializeQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000001404440b 5. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5594: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000140135fb 6. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000140127f9 7. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000014011fce 8. /build/src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000001406ce8a 9. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000014973b42 10. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000001497268d 11. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000014974d24 12. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001492924b 13. /build/src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88641 14. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 15. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 16. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 17. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 18. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 19. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 20. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 21. ? @ 0x00007fbc6213eac3 22. ? @ 0x00007fbc621d0850 2025.07.28 11:56:08.962895 [ 4963 ] {} TCPHandler: Code: 60. DB::Exception: Unknown table expression identifier 'ghdata' in scope SELECT data.payload.commits.:`Array(JSON)`.author.name AS name, count() AS c FROM ghdata ARRAY JOIN data.payload.commits.:`Array(JSON)`.author.name GROUP BY name ORDER BY c DESC, name ASC LIMIT 5. (UNKNOWN_TABLE), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x000000000a6a1e2b 4. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:4372: DB::QueryAnalyzer::initializeQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000001404440b 5. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5594: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000140135fb 6. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000140127f9 7. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000014011fce 8. /build/src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000001406ce8a 9. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000014973b42 10. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000001497268d 11. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000014974d24 12. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001492924b 13. /build/src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88641 14. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 15. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 16. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 17. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 18. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 19. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 20. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 21. ? @ 0x00007fbc6213eac3 22. ? @ 0x00007fbc621d0850 2025.07.28 11:56:09.130142 [ 4963 ] {923dc602-f2fa-4643-9c30-bfa04b1919ae} executeQuery: Code: 60. DB::Exception: Unknown table expression identifier 'ghdata' in scope SELECT max(data.payload.pull_request.assignees.:`Array(JSON)`.size0) FROM ghdata. (UNKNOWN_TABLE) (version 25.3.6.10636.altinitytest (altinity build)) (from [::1]:32962) (comment: 03272_ghdata_object_to_json_alter_shared_data.sh) (query 1, line 1) (in query: SELECT max(data.payload.pull_request.assignees[].size0) FROM ghdata), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x000000000a6a1e2b 4. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:4372: DB::QueryAnalyzer::initializeQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000001404440b 5. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5594: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000140135fb 6. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000140127f9 7. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000014011fce 8. /build/src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000001406ce8a 9. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000014973b42 10. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000001497268d 11. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000014974d24 12. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001492924b 13. /build/src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88641 14. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 15. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 16. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 17. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 18. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 19. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 20. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 21. ? @ 0x00007fbc6213eac3 22. ? @ 0x00007fbc621d0850 2025.07.28 11:56:09.144270 [ 4963 ] {} TCPHandler: Code: 60. DB::Exception: Unknown table expression identifier 'ghdata' in scope SELECT max(data.payload.pull_request.assignees.:`Array(JSON)`.size0) FROM ghdata. (UNKNOWN_TABLE), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x000000000a6a1e2b 4. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:4372: DB::QueryAnalyzer::initializeQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000001404440b 5. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5594: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000140135fb 6. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000140127f9 7. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000014011fce 8. /build/src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000001406ce8a 9. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000014973b42 10. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000001497268d 11. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000014974d24 12. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001492924b 13. /build/src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88641 14. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 15. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 16. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 17. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 18. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 19. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 20. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 21. ? @ 0x00007fbc6213eac3 22. ? @ 0x00007fbc621d0850 2025.07.28 11:56:09.769024 [ 3964 ] {} test_13.rmt2 (7f9b740d-015c-470e-8cc6-8ba33be0dc63): auto DB::StorageReplicatedMergeTree::processQueueEntry(ReplicatedMergeTreeQueue::SelectedEntryPtr)::(anonymous class)::operator()(LogEntryPtr &) const: Code: 86. DB::HTTPException: Received error from remote server http://146b4357c08d:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Ftest%2F01165%2Ftest_13%2Frmt%2Freplicas%2F1&part=20250728_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.6.10636.altinitytest (altinity build)) '. (RECEIVED_ERROR_FROM_REMOTE_IO_SERVER), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.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 const&, int&&, String const&, unsigned long&&, String const&) @ 0x000000000feda8d9 4. /build/src/IO/HTTPCommon.cpp:104: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x000000000feda6e2 5. /build/src/IO/HTTPCommon.cpp:93: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x000000000feda537 6. /build/src/IO/ReadWriteBufferFromHTTP.cpp:277: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x000000001184a4c4 7. /build/src/IO/ReadWriteBufferFromHTTP.cpp:285: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x000000001184a615 8. /build/src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x000000001184ae59 9. /build/src/IO/ReadWriteBufferFromHTTP.cpp:472: void std::__function::__policy_invoker::__call_impl[abi:se190107]>(std::__function::__policy_storage const*) @ 0x000000001184cedd 10. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001184858b 11. /build/src/IO/ReadWriteBufferFromHTTP.cpp:465: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x000000001184bf0b 12. /build/src/IO/ReadBuffer.h:60: DB::ReadBuffer::next() @ 0x000000000a148c7b 13. /build/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) @ 0x0000000011849fb2 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]>&)>&, 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&) @ 0x0000000011841980 15. /build/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) @ 0x000000001621208e 16. /build/src/Storages/StorageReplicatedMergeTree.cpp:5228: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl[abi:se190107] const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000015f9a5fe 17. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000015ed8bfd 18. /build/src/Storages/StorageReplicatedMergeTree.cpp:2514: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x0000000015ec9aab 19. /build/src/Storages/StorageReplicatedMergeTree.cpp:2349: DB::StorageReplicatedMergeTree::executeLogEntry(DB::ReplicatedMergeTreeLogEntry&) @ 0x0000000015eba91b 20. /build/src/Storages/StorageReplicatedMergeTree.cpp:3876: bool std::__function::__policy_invoker&)>::__call_impl[abi:se190107])::$_1, bool (std::shared_ptr&)>>(std::__function::__policy_storage const*, std::shared_ptr&) @ 0x0000000015f9837e 21. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000165d6fc3 22. /build/src/Storages/StorageReplicatedMergeTree.cpp:3872: DB::StorageReplicatedMergeTree::processQueueEntry(std::shared_ptr) @ 0x0000000015efc18a 23. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001624c1b2 24. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000162f9c70 25. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x00000000162fa55a 26. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc6653 27. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000000fccc4c3 28. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc3d92 29. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fcca080 30. ? @ 0x00007fbc6213eac3 31. ? @ 0x00007fbc621d0850 (version 25.3.6.10636.altinitytest (altinity build)) 2025.07.28 11:56:10.312020 [ 3972 ] {} test_13.rmt2 (7f9b740d-015c-470e-8cc6-8ba33be0dc63): auto DB::StorageReplicatedMergeTree::processQueueEntry(ReplicatedMergeTreeQueue::SelectedEntryPtr)::(anonymous class)::operator()(LogEntryPtr &) const: Code: 86. DB::HTTPException: Received error from remote server http://146b4357c08d:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Ftest%2F01165%2Ftest_13%2Frmt%2Freplicas%2F1&part=20250728_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.6.10636.altinitytest (altinity build)) '. (RECEIVED_ERROR_FROM_REMOTE_IO_SERVER), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.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 const&, int&&, String const&, unsigned long&&, String const&) @ 0x000000000feda8d9 4. /build/src/IO/HTTPCommon.cpp:104: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x000000000feda6e2 5. /build/src/IO/HTTPCommon.cpp:93: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x000000000feda537 6. /build/src/IO/ReadWriteBufferFromHTTP.cpp:277: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x000000001184a4c4 7. /build/src/IO/ReadWriteBufferFromHTTP.cpp:285: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x000000001184a615 8. /build/src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x000000001184ae59 9. /build/src/IO/ReadWriteBufferFromHTTP.cpp:472: void std::__function::__policy_invoker::__call_impl[abi:se190107]>(std::__function::__policy_storage const*) @ 0x000000001184cedd 10. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001184858b 11. /build/src/IO/ReadWriteBufferFromHTTP.cpp:465: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x000000001184bf0b 12. /build/src/IO/ReadBuffer.h:60: DB::ReadBuffer::next() @ 0x000000000a148c7b 13. /build/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) @ 0x0000000011849fb2 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]>&)>&, 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&) @ 0x0000000011841980 15. /build/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) @ 0x000000001621208e 16. /build/src/Storages/StorageReplicatedMergeTree.cpp:5228: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl[abi:se190107] const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000015f9a5fe 17. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000015ed8bfd 18. /build/src/Storages/StorageReplicatedMergeTree.cpp:2514: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x0000000015ec9aab 19. /build/src/Storages/StorageReplicatedMergeTree.cpp:2349: DB::StorageReplicatedMergeTree::executeLogEntry(DB::ReplicatedMergeTreeLogEntry&) @ 0x0000000015eba91b 20. /build/src/Storages/StorageReplicatedMergeTree.cpp:3876: bool std::__function::__policy_invoker&)>::__call_impl[abi:se190107])::$_1, bool (std::shared_ptr&)>>(std::__function::__policy_storage const*, std::shared_ptr&) @ 0x0000000015f9837e 21. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000165d6fc3 22. /build/src/Storages/StorageReplicatedMergeTree.cpp:3872: DB::StorageReplicatedMergeTree::processQueueEntry(std::shared_ptr) @ 0x0000000015efc18a 23. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001624c1b2 24. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000162f9c70 25. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x00000000162fa55a 26. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc6653 27. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000000fccc4c3 28. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc3d92 29. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fcca080 30. ? @ 0x00007fbc6213eac3 31. ? @ 0x00007fbc621d0850 (version 25.3.6.10636.altinitytest (altinity build)) 2025.07.28 11:56:11.352889 [ 3976 ] {} test_13.rmt2 (7f9b740d-015c-470e-8cc6-8ba33be0dc63): auto DB::StorageReplicatedMergeTree::processQueueEntry(ReplicatedMergeTreeQueue::SelectedEntryPtr)::(anonymous class)::operator()(LogEntryPtr &) const: Code: 86. DB::HTTPException: Received error from remote server http://146b4357c08d:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Ftest%2F01165%2Ftest_13%2Frmt%2Freplicas%2F1&part=20250728_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.6.10636.altinitytest (altinity build)) '. (RECEIVED_ERROR_FROM_REMOTE_IO_SERVER), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.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 const&, int&&, String const&, unsigned long&&, String const&) @ 0x000000000feda8d9 4. /build/src/IO/HTTPCommon.cpp:104: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x000000000feda6e2 5. /build/src/IO/HTTPCommon.cpp:93: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x000000000feda537 6. /build/src/IO/ReadWriteBufferFromHTTP.cpp:277: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x000000001184a4c4 7. /build/src/IO/ReadWriteBufferFromHTTP.cpp:285: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x000000001184a615 8. /build/src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x000000001184ae59 9. /build/src/IO/ReadWriteBufferFromHTTP.cpp:472: void std::__function::__policy_invoker::__call_impl[abi:se190107]>(std::__function::__policy_storage const*) @ 0x000000001184cedd 10. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001184858b 11. /build/src/IO/ReadWriteBufferFromHTTP.cpp:465: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x000000001184bf0b 12. /build/src/IO/ReadBuffer.h:60: DB::ReadBuffer::next() @ 0x000000000a148c7b 13. /build/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) @ 0x0000000011849fb2 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]>&)>&, 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&) @ 0x0000000011841980 15. /build/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) @ 0x000000001621208e 16. /build/src/Storages/StorageReplicatedMergeTree.cpp:5228: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl[abi:se190107] const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000015f9a5fe 17. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000015ed8bfd 18. /build/src/Storages/StorageReplicatedMergeTree.cpp:2514: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x0000000015ec9aab 19. /build/src/Storages/StorageReplicatedMergeTree.cpp:2349: DB::StorageReplicatedMergeTree::executeLogEntry(DB::ReplicatedMergeTreeLogEntry&) @ 0x0000000015eba91b 20. /build/src/Storages/StorageReplicatedMergeTree.cpp:3876: bool std::__function::__policy_invoker&)>::__call_impl[abi:se190107])::$_1, bool (std::shared_ptr&)>>(std::__function::__policy_storage const*, std::shared_ptr&) @ 0x0000000015f9837e 21. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000165d6fc3 22. /build/src/Storages/StorageReplicatedMergeTree.cpp:3872: DB::StorageReplicatedMergeTree::processQueueEntry(std::shared_ptr) @ 0x0000000015efc18a 23. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001624c1b2 24. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000162f9c70 25. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x00000000162fa55a 26. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc6653 27. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000000fccc4c3 28. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc3d92 29. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fcca080 30. ? @ 0x00007fbc6213eac3 31. ? @ 0x00007fbc621d0850 (version 25.3.6.10636.altinitytest (altinity build)) 2025.07.28 11:56:12.248924 [ 3963 ] {} test_13.rmt2 (7f9b740d-015c-470e-8cc6-8ba33be0dc63): auto DB::StorageReplicatedMergeTree::processQueueEntry(ReplicatedMergeTreeQueue::SelectedEntryPtr)::(anonymous class)::operator()(LogEntryPtr &) const: Code: 86. DB::HTTPException: Received error from remote server http://146b4357c08d:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Ftest%2F01165%2Ftest_13%2Frmt%2Freplicas%2F1&part=20250728_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.6.10636.altinitytest (altinity build)) '. (RECEIVED_ERROR_FROM_REMOTE_IO_SERVER), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.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 const&, int&&, String const&, unsigned long&&, String const&) @ 0x000000000feda8d9 4. /build/src/IO/HTTPCommon.cpp:104: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x000000000feda6e2 5. /build/src/IO/HTTPCommon.cpp:93: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x000000000feda537 6. /build/src/IO/ReadWriteBufferFromHTTP.cpp:277: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x000000001184a4c4 7. /build/src/IO/ReadWriteBufferFromHTTP.cpp:285: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x000000001184a615 8. /build/src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x000000001184ae59 9. /build/src/IO/ReadWriteBufferFromHTTP.cpp:472: void std::__function::__policy_invoker::__call_impl[abi:se190107]>(std::__function::__policy_storage const*) @ 0x000000001184cedd 10. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001184858b 11. /build/src/IO/ReadWriteBufferFromHTTP.cpp:465: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x000000001184bf0b 12. /build/src/IO/ReadBuffer.h:60: DB::ReadBuffer::next() @ 0x000000000a148c7b 13. /build/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) @ 0x0000000011849fb2 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]>&)>&, 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&) @ 0x0000000011841980 15. /build/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) @ 0x000000001621208e 16. /build/src/Storages/StorageReplicatedMergeTree.cpp:5228: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl[abi:se190107] const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000015f9a5fe 17. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000015ed8bfd 18. /build/src/Storages/StorageReplicatedMergeTree.cpp:2514: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x0000000015ec9aab 19. /build/src/Storages/StorageReplicatedMergeTree.cpp:2349: DB::StorageReplicatedMergeTree::executeLogEntry(DB::ReplicatedMergeTreeLogEntry&) @ 0x0000000015eba91b 20. /build/src/Storages/StorageReplicatedMergeTree.cpp:3876: bool std::__function::__policy_invoker&)>::__call_impl[abi:se190107])::$_1, bool (std::shared_ptr&)>>(std::__function::__policy_storage const*, std::shared_ptr&) @ 0x0000000015f9837e 21. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000165d6fc3 22. /build/src/Storages/StorageReplicatedMergeTree.cpp:3872: DB::StorageReplicatedMergeTree::processQueueEntry(std::shared_ptr) @ 0x0000000015efc18a 23. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001624c1b2 24. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000162f9c70 25. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x00000000162fa55a 26. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc6653 27. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000000fccc4c3 28. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc3d92 29. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fcca080 30. ? @ 0x00007fbc6213eac3 31. ? @ 0x00007fbc621d0850 (version 25.3.6.10636.altinitytest (altinity build)) 2025.07.28 11:56:13.077102 [ 3967 ] {} test_13.rmt2 (7f9b740d-015c-470e-8cc6-8ba33be0dc63): auto DB::StorageReplicatedMergeTree::processQueueEntry(ReplicatedMergeTreeQueue::SelectedEntryPtr)::(anonymous class)::operator()(LogEntryPtr &) const: Code: 86. DB::HTTPException: Received error from remote server http://146b4357c08d:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Ftest%2F01165%2Ftest_13%2Frmt%2Freplicas%2F1&part=20250728_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.6.10636.altinitytest (altinity build)) '. (RECEIVED_ERROR_FROM_REMOTE_IO_SERVER), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.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 const&, int&&, String const&, unsigned long&&, String const&) @ 0x000000000feda8d9 4. /build/src/IO/HTTPCommon.cpp:104: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x000000000feda6e2 5. /build/src/IO/HTTPCommon.cpp:93: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x000000000feda537 6. /build/src/IO/ReadWriteBufferFromHTTP.cpp:277: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x000000001184a4c4 7. /build/src/IO/ReadWriteBufferFromHTTP.cpp:285: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x000000001184a615 8. /build/src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x000000001184ae59 9. /build/src/IO/ReadWriteBufferFromHTTP.cpp:472: void std::__function::__policy_invoker::__call_impl[abi:se190107]>(std::__function::__policy_storage const*) @ 0x000000001184cedd 10. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001184858b 11. /build/src/IO/ReadWriteBufferFromHTTP.cpp:465: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x000000001184bf0b 12. /build/src/IO/ReadBuffer.h:60: DB::ReadBuffer::next() @ 0x000000000a148c7b 13. /build/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) @ 0x0000000011849fb2 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]>&)>&, 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&) @ 0x0000000011841980 15. /build/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) @ 0x000000001621208e 16. /build/src/Storages/StorageReplicatedMergeTree.cpp:5228: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl[abi:se190107] const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000015f9a5fe 17. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000015ed8bfd 18. /build/src/Storages/StorageReplicatedMergeTree.cpp:2514: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x0000000015ec9aab 19. /build/src/Storages/StorageReplicatedMergeTree.cpp:2349: DB::StorageReplicatedMergeTree::executeLogEntry(DB::ReplicatedMergeTreeLogEntry&) @ 0x0000000015eba91b 20. /build/src/Storages/StorageReplicatedMergeTree.cpp:3876: bool std::__function::__policy_invoker&)>::__call_impl[abi:se190107])::$_1, bool (std::shared_ptr&)>>(std::__function::__policy_storage const*, std::shared_ptr&) @ 0x0000000015f9837e 21. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000165d6fc3 22. /build/src/Storages/StorageReplicatedMergeTree.cpp:3872: DB::StorageReplicatedMergeTree::processQueueEntry(std::shared_ptr) @ 0x0000000015efc18a 23. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001624c1b2 24. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000162f9c70 25. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x00000000162fa55a 26. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc6653 27. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000000fccc4c3 28. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc3d92 29. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fcca080 30. ? @ 0x00007fbc6213eac3 31. ? @ 0x00007fbc621d0850 (version 25.3.6.10636.altinitytest (altinity build)) 2025.07.28 11:56:13.223380 [ 3974 ] {} test_13.rmt2 (7f9b740d-015c-470e-8cc6-8ba33be0dc63): auto DB::StorageReplicatedMergeTree::processQueueEntry(ReplicatedMergeTreeQueue::SelectedEntryPtr)::(anonymous class)::operator()(LogEntryPtr &) const: Code: 86. DB::HTTPException: Received error from remote server http://146b4357c08d:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Ftest%2F01165%2Ftest_13%2Frmt%2Freplicas%2F1&part=20250728_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.6.10636.altinitytest (altinity build)) '. (RECEIVED_ERROR_FROM_REMOTE_IO_SERVER), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.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 const&, int&&, String const&, unsigned long&&, String const&) @ 0x000000000feda8d9 4. /build/src/IO/HTTPCommon.cpp:104: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x000000000feda6e2 5. /build/src/IO/HTTPCommon.cpp:93: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x000000000feda537 6. /build/src/IO/ReadWriteBufferFromHTTP.cpp:277: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x000000001184a4c4 7. /build/src/IO/ReadWriteBufferFromHTTP.cpp:285: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x000000001184a615 8. /build/src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x000000001184ae59 9. /build/src/IO/ReadWriteBufferFromHTTP.cpp:472: void std::__function::__policy_invoker::__call_impl[abi:se190107]>(std::__function::__policy_storage const*) @ 0x000000001184cedd 10. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001184858b 11. /build/src/IO/ReadWriteBufferFromHTTP.cpp:465: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x000000001184bf0b 12. /build/src/IO/ReadBuffer.h:60: DB::ReadBuffer::next() @ 0x000000000a148c7b 13. /build/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) @ 0x0000000011849fb2 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]>&)>&, 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&) @ 0x0000000011841980 15. /build/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) @ 0x000000001621208e 16. /build/src/Storages/StorageReplicatedMergeTree.cpp:5228: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl[abi:se190107] const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000015f9a5fe 17. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000015ed8bfd 18. /build/src/Storages/StorageReplicatedMergeTree.cpp:2514: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x0000000015ec9aab 19. /build/src/Storages/StorageReplicatedMergeTree.cpp:2349: DB::StorageReplicatedMergeTree::executeLogEntry(DB::ReplicatedMergeTreeLogEntry&) @ 0x0000000015eba91b 20. /build/src/Storages/StorageReplicatedMergeTree.cpp:3876: bool std::__function::__policy_invoker&)>::__call_impl[abi:se190107])::$_1, bool (std::shared_ptr&)>>(std::__function::__policy_storage const*, std::shared_ptr&) @ 0x0000000015f9837e 21. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000165d6fc3 22. /build/src/Storages/StorageReplicatedMergeTree.cpp:3872: DB::StorageReplicatedMergeTree::processQueueEntry(std::shared_ptr) @ 0x0000000015efc18a 23. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001624c1b2 24. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000162f9c70 25. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x00000000162fa55a 26. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc6653 27. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000000fccc4c3 28. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc3d92 29. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fcca080 30. ? @ 0x00007fbc6213eac3 31. ? @ 0x00007fbc621d0850 (version 25.3.6.10636.altinitytest (altinity build)) 2025.07.28 11:56:13.617164 [ 17203 ] {90d60d87-2335-4baa-87b2-d6c11c9535b3} 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.6.10636.altinitytest (altinity build)) (from [::1]:46666) (comment: 02973_block_number_sparse_serialization_and_mutation.sql) (query 3, line 8) (in query: CREATE TABLE table_with_some_columns (`key` UInt64, `value0` UInt8) ENGINE = ReplicatedMergeTree('/clickhouse/tables/{database}/table_with_some_columns', '1') ORDER BY key SETTINGS allow_experimental_block_number_column = 1, ratio_of_defaults_for_sparse_serialization = 0.0001, min_bytes_for_wide_part = 0, replace_long_file_name_to_hash = 0, index_granularity = 62796, max_file_name_length = 0, min_bytes_for_full_part_storage = 192154606, compact_parts_max_bytes_to_buffer = 291938745, compact_parts_max_granules_to_buffer = 256, compact_parts_merge_max_bytes_to_prefetch_part = 25388918, merge_max_block_size = 2765, old_parts_lifetime = 472., prefer_fetch_merged_part_size_threshold = 7019567082, vertical_merge_algorithm_min_rows_to_activate = 1, vertical_merge_algorithm_min_columns_to_activate = 100, min_merge_bytes_to_use_direct_io = 6227390156, index_granularity_bytes = 14488977, use_const_adaptive_granularity = false, enable_index_granularity_compression = false, concurrent_part_removal_threshold = 85, allow_vertical_merges_from_compact_to_wide_parts = false, enable_block_number_column = false, enable_block_offset_column = true, cache_populated_by_fetch = true, marks_compress_block_size = 98213, primary_key_compress_block_size = 39262, 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. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000000a074fcb 4. /build/src/Databases/DatabaseReplicated.cpp:959: DB::DatabaseReplicated::checkTableEngine(DB::ASTCreateQuery const&, DB::ASTStorage&, std::shared_ptr) const @ 0x0000000013d9cf56 5. /build/src/Databases/DatabaseReplicated.cpp:1083: DB::DatabaseReplicated::checkQueryValid(std::shared_ptr const&, std::shared_ptr) const @ 0x0000000013d9ebb5 6. /build/src/Databases/DatabaseReplicated.cpp:1130: DB::DatabaseReplicated::tryEnqueueReplicatedDDL(std::shared_ptr const&, std::shared_ptr, DB::QueryFlags) @ 0x0000000013d9f10b 7. /build/src/Interpreters/InterpreterCreateQuery.cpp:1723: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000148f96f8 8. /build/src/Interpreters/InterpreterCreateQuery.cpp:2352: DB::InterpreterCreateQuery::execute() @ 0x0000000014905a41 9. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88dc9 10. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 11. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 12. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 13. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 14. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 16. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 17. ? @ 0x00007fbc6213eac3 18. ? @ 0x00007fbc621d0850 2025.07.28 11:56:13.630979 [ 17203 ] {} 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. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000000a074fcb 4. /build/src/Databases/DatabaseReplicated.cpp:959: DB::DatabaseReplicated::checkTableEngine(DB::ASTCreateQuery const&, DB::ASTStorage&, std::shared_ptr) const @ 0x0000000013d9cf56 5. /build/src/Databases/DatabaseReplicated.cpp:1083: DB::DatabaseReplicated::checkQueryValid(std::shared_ptr const&, std::shared_ptr) const @ 0x0000000013d9ebb5 6. /build/src/Databases/DatabaseReplicated.cpp:1130: DB::DatabaseReplicated::tryEnqueueReplicatedDDL(std::shared_ptr const&, std::shared_ptr, DB::QueryFlags) @ 0x0000000013d9f10b 7. /build/src/Interpreters/InterpreterCreateQuery.cpp:1723: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000148f96f8 8. /build/src/Interpreters/InterpreterCreateQuery.cpp:2352: DB::InterpreterCreateQuery::execute() @ 0x0000000014905a41 9. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88dc9 10. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 11. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 12. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 13. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 14. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 16. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 17. ? @ 0x00007fbc6213eac3 18. ? @ 0x00007fbc621d0850 2025.07.28 11:56:13.921761 [ 5825 ] {0ca6a85d-6cb7-4a8f-a363-7cd674ce553b} executeQuery: Code: 344. DB::Exception: DELETE query is not allowed for table test_voiat7g4.users_compact because as it has projections and setting lightweight_mutation_projection_mode is set to THROW. User should change lightweight_mutation_projection_mode OR drop all the projections manually before running the query. (SUPPORT_IS_DISABLED) (version 25.3.6.10636.altinitytest (altinity build)) (from [::1]:46646) (comment: 03161_lightweight_delete_projection.sql) (query 8, line 28) (in query: DELETE FROM users_compact WHERE uid = 1231;), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x000000000a06b56b 4. /build/src/Interpreters/InterpreterDeleteQuery.cpp:113: DB::InterpreterDeleteQuery::execute() @ 0x0000000014d00fc3 5. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88dc9 6. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 7. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 8. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 9. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 10. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 11. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 12. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 13. ? @ 0x00007fbc6213eac3 14. ? @ 0x00007fbc621d0850 2025.07.28 11:56:13.934513 [ 5825 ] {} TCPHandler: Code: 344. DB::Exception: DELETE query is not allowed for table test_voiat7g4.users_compact because as it has projections and setting lightweight_mutation_projection_mode is set to THROW. User should change lightweight_mutation_projection_mode OR drop all the projections manually before running the query. (SUPPORT_IS_DISABLED), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x000000000a06b56b 4. /build/src/Interpreters/InterpreterDeleteQuery.cpp:113: DB::InterpreterDeleteQuery::execute() @ 0x0000000014d00fc3 5. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88dc9 6. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 7. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 8. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 9. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 10. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 11. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 12. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 13. ? @ 0x00007fbc6213eac3 14. ? @ 0x00007fbc621d0850 2025.07.28 11:56:14.016870 [ 3968 ] {} test_13.rmt2 (7f9b740d-015c-470e-8cc6-8ba33be0dc63): auto DB::StorageReplicatedMergeTree::processQueueEntry(ReplicatedMergeTreeQueue::SelectedEntryPtr)::(anonymous class)::operator()(LogEntryPtr &) const: Code: 86. DB::HTTPException: Received error from remote server http://146b4357c08d:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Ftest%2F01165%2Ftest_13%2Frmt%2Freplicas%2F1&part=20250728_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.6.10636.altinitytest (altinity build)) '. (RECEIVED_ERROR_FROM_REMOTE_IO_SERVER), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.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 const&, int&&, String const&, unsigned long&&, String const&) @ 0x000000000feda8d9 4. /build/src/IO/HTTPCommon.cpp:104: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x000000000feda6e2 5. /build/src/IO/HTTPCommon.cpp:93: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x000000000feda537 6. /build/src/IO/ReadWriteBufferFromHTTP.cpp:277: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x000000001184a4c4 7. /build/src/IO/ReadWriteBufferFromHTTP.cpp:285: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x000000001184a615 8. /build/src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x000000001184ae59 9. /build/src/IO/ReadWriteBufferFromHTTP.cpp:472: void std::__function::__policy_invoker::__call_impl[abi:se190107]>(std::__function::__policy_storage const*) @ 0x000000001184cedd 10. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001184858b 11. /build/src/IO/ReadWriteBufferFromHTTP.cpp:465: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x000000001184bf0b 12. /build/src/IO/ReadBuffer.h:60: DB::ReadBuffer::next() @ 0x000000000a148c7b 13. /build/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) @ 0x0000000011849fb2 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]>&)>&, 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&) @ 0x0000000011841980 15. /build/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) @ 0x000000001621208e 16. /build/src/Storages/StorageReplicatedMergeTree.cpp:5228: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl[abi:se190107] const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000015f9a5fe 17. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000015ed8bfd 18. /build/src/Storages/StorageReplicatedMergeTree.cpp:2514: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x0000000015ec9aab 19. /build/src/Storages/StorageReplicatedMergeTree.cpp:2349: DB::StorageReplicatedMergeTree::executeLogEntry(DB::ReplicatedMergeTreeLogEntry&) @ 0x0000000015eba91b 20. /build/src/Storages/StorageReplicatedMergeTree.cpp:3876: bool std::__function::__policy_invoker&)>::__call_impl[abi:se190107])::$_1, bool (std::shared_ptr&)>>(std::__function::__policy_storage const*, std::shared_ptr&) @ 0x0000000015f9837e 21. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000165d6fc3 22. /build/src/Storages/StorageReplicatedMergeTree.cpp:3872: DB::StorageReplicatedMergeTree::processQueueEntry(std::shared_ptr) @ 0x0000000015efc18a 23. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001624c1b2 24. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000162f9c70 25. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x00000000162fa55a 26. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc6653 27. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000000fccc4c3 28. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc3d92 29. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fcca080 30. ? @ 0x00007fbc6213eac3 31. ? @ 0x00007fbc621d0850 (version 25.3.6.10636.altinitytest (altinity build)) 2025.07.28 11:56:14.084794 [ 3968 ] {} test_13.rmt2 (7f9b740d-015c-470e-8cc6-8ba33be0dc63): auto DB::StorageReplicatedMergeTree::processQueueEntry(ReplicatedMergeTreeQueue::SelectedEntryPtr)::(anonymous class)::operator()(LogEntryPtr &) const: Code: 86. DB::HTTPException: Received error from remote server http://146b4357c08d:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Ftest%2F01165%2Ftest_13%2Frmt%2Freplicas%2F1&part=20250728_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.6.10636.altinitytest (altinity build)) '. (RECEIVED_ERROR_FROM_REMOTE_IO_SERVER), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.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 const&, int&&, String const&, unsigned long&&, String const&) @ 0x000000000feda8d9 4. /build/src/IO/HTTPCommon.cpp:104: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x000000000feda6e2 5. /build/src/IO/HTTPCommon.cpp:93: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x000000000feda537 6. /build/src/IO/ReadWriteBufferFromHTTP.cpp:277: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x000000001184a4c4 7. /build/src/IO/ReadWriteBufferFromHTTP.cpp:285: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x000000001184a615 8. /build/src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x000000001184ae59 9. /build/src/IO/ReadWriteBufferFromHTTP.cpp:472: void std::__function::__policy_invoker::__call_impl[abi:se190107]>(std::__function::__policy_storage const*) @ 0x000000001184cedd 10. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001184858b 11. /build/src/IO/ReadWriteBufferFromHTTP.cpp:465: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x000000001184bf0b 12. /build/src/IO/ReadBuffer.h:60: DB::ReadBuffer::next() @ 0x000000000a148c7b 13. /build/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) @ 0x0000000011849fb2 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]>&)>&, 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&) @ 0x0000000011841980 15. /build/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) @ 0x000000001621208e 16. /build/src/Storages/StorageReplicatedMergeTree.cpp:5228: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl[abi:se190107] const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000015f9a5fe 17. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000015ed8bfd 18. /build/src/Storages/StorageReplicatedMergeTree.cpp:2514: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x0000000015ec9aab 19. /build/src/Storages/StorageReplicatedMergeTree.cpp:2349: DB::StorageReplicatedMergeTree::executeLogEntry(DB::ReplicatedMergeTreeLogEntry&) @ 0x0000000015eba91b 20. /build/src/Storages/StorageReplicatedMergeTree.cpp:3876: bool std::__function::__policy_invoker&)>::__call_impl[abi:se190107])::$_1, bool (std::shared_ptr&)>>(std::__function::__policy_storage const*, std::shared_ptr&) @ 0x0000000015f9837e 21. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000165d6fc3 22. /build/src/Storages/StorageReplicatedMergeTree.cpp:3872: DB::StorageReplicatedMergeTree::processQueueEntry(std::shared_ptr) @ 0x0000000015efc18a 23. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001624c1b2 24. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000162f9c70 25. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x00000000162fa55a 26. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc6653 27. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000000fccc4c3 28. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc3d92 29. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fcca080 30. ? @ 0x00007fbc6213eac3 31. ? @ 0x00007fbc621d0850 (version 25.3.6.10636.altinitytest (altinity build)) 2025.07.28 11:56:14.743120 [ 3967 ] {} test_13.rmt2 (7f9b740d-015c-470e-8cc6-8ba33be0dc63): auto DB::StorageReplicatedMergeTree::processQueueEntry(ReplicatedMergeTreeQueue::SelectedEntryPtr)::(anonymous class)::operator()(LogEntryPtr &) const: Code: 86. DB::HTTPException: Received error from remote server http://146b4357c08d:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Ftest%2F01165%2Ftest_13%2Frmt%2Freplicas%2F1&part=20250728_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.6.10636.altinitytest (altinity build)) '. (RECEIVED_ERROR_FROM_REMOTE_IO_SERVER), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.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 const&, int&&, String const&, unsigned long&&, String const&) @ 0x000000000feda8d9 4. /build/src/IO/HTTPCommon.cpp:104: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x000000000feda6e2 5. /build/src/IO/HTTPCommon.cpp:93: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x000000000feda537 6. /build/src/IO/ReadWriteBufferFromHTTP.cpp:277: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x000000001184a4c4 7. /build/src/IO/ReadWriteBufferFromHTTP.cpp:285: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x000000001184a615 8. /build/src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x000000001184ae59 9. /build/src/IO/ReadWriteBufferFromHTTP.cpp:472: void std::__function::__policy_invoker::__call_impl[abi:se190107]>(std::__function::__policy_storage const*) @ 0x000000001184cedd 10. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001184858b 11. /build/src/IO/ReadWriteBufferFromHTTP.cpp:465: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x000000001184bf0b 12. /build/src/IO/ReadBuffer.h:60: DB::ReadBuffer::next() @ 0x000000000a148c7b 13. /build/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) @ 0x0000000011849fb2 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]>&)>&, 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&) @ 0x0000000011841980 15. /build/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) @ 0x000000001621208e 16. /build/src/Storages/StorageReplicatedMergeTree.cpp:5228: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl[abi:se190107] const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000015f9a5fe 17. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000015ed8bfd 18. /build/src/Storages/StorageReplicatedMergeTree.cpp:2514: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x0000000015ec9aab 19. /build/src/Storages/StorageReplicatedMergeTree.cpp:2349: DB::StorageReplicatedMergeTree::executeLogEntry(DB::ReplicatedMergeTreeLogEntry&) @ 0x0000000015eba91b 20. /build/src/Storages/StorageReplicatedMergeTree.cpp:3876: bool std::__function::__policy_invoker&)>::__call_impl[abi:se190107])::$_1, bool (std::shared_ptr&)>>(std::__function::__policy_storage const*, std::shared_ptr&) @ 0x0000000015f9837e 21. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000165d6fc3 22. /build/src/Storages/StorageReplicatedMergeTree.cpp:3872: DB::StorageReplicatedMergeTree::processQueueEntry(std::shared_ptr) @ 0x0000000015efc18a 23. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001624c1b2 24. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000162f9c70 25. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x00000000162fa55a 26. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc6653 27. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000000fccc4c3 28. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc3d92 29. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fcca080 30. ? @ 0x00007fbc6213eac3 31. ? @ 0x00007fbc621d0850 (version 25.3.6.10636.altinitytest (altinity build)) 2025.07.28 11:56:15.303810 [ 3972 ] {} test_13.rmt2 (7f9b740d-015c-470e-8cc6-8ba33be0dc63): auto DB::StorageReplicatedMergeTree::processQueueEntry(ReplicatedMergeTreeQueue::SelectedEntryPtr)::(anonymous class)::operator()(LogEntryPtr &) const: Code: 86. DB::HTTPException: Received error from remote server http://146b4357c08d:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Ftest%2F01165%2Ftest_13%2Frmt%2Freplicas%2F1&part=20250728_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.6.10636.altinitytest (altinity build)) '. (RECEIVED_ERROR_FROM_REMOTE_IO_SERVER), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.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 const&, int&&, String const&, unsigned long&&, String const&) @ 0x000000000feda8d9 4. /build/src/IO/HTTPCommon.cpp:104: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x000000000feda6e2 5. /build/src/IO/HTTPCommon.cpp:93: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x000000000feda537 6. /build/src/IO/ReadWriteBufferFromHTTP.cpp:277: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x000000001184a4c4 7. /build/src/IO/ReadWriteBufferFromHTTP.cpp:285: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x000000001184a615 8. /build/src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x000000001184ae59 9. /build/src/IO/ReadWriteBufferFromHTTP.cpp:472: void std::__function::__policy_invoker::__call_impl[abi:se190107]>(std::__function::__policy_storage const*) @ 0x000000001184cedd 10. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001184858b 11. /build/src/IO/ReadWriteBufferFromHTTP.cpp:465: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x000000001184bf0b 12. /build/src/IO/ReadBuffer.h:60: DB::ReadBuffer::next() @ 0x000000000a148c7b 13. /build/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) @ 0x0000000011849fb2 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]>&)>&, 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&) @ 0x0000000011841980 15. /build/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) @ 0x000000001621208e 16. /build/src/Storages/StorageReplicatedMergeTree.cpp:5228: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl[abi:se190107] const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000015f9a5fe 17. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000015ed8bfd 18. /build/src/Storages/StorageReplicatedMergeTree.cpp:2514: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x0000000015ec9aab 19. /build/src/Storages/StorageReplicatedMergeTree.cpp:2349: DB::StorageReplicatedMergeTree::executeLogEntry(DB::ReplicatedMergeTreeLogEntry&) @ 0x0000000015eba91b 20. /build/src/Storages/StorageReplicatedMergeTree.cpp:3876: bool std::__function::__policy_invoker&)>::__call_impl[abi:se190107])::$_1, bool (std::shared_ptr&)>>(std::__function::__policy_storage const*, std::shared_ptr&) @ 0x0000000015f9837e 21. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000165d6fc3 22. /build/src/Storages/StorageReplicatedMergeTree.cpp:3872: DB::StorageReplicatedMergeTree::processQueueEntry(std::shared_ptr) @ 0x0000000015efc18a 23. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001624c1b2 24. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000162f9c70 25. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x00000000162fa55a 26. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc6653 27. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000000fccc4c3 28. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc3d92 29. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fcca080 30. ? @ 0x00007fbc6213eac3 31. ? @ 0x00007fbc621d0850 (version 25.3.6.10636.altinitytest (altinity build)) 2025.07.28 11:56:16.251872 [ 3976 ] {} test_13.rmt2 (7f9b740d-015c-470e-8cc6-8ba33be0dc63): auto DB::StorageReplicatedMergeTree::processQueueEntry(ReplicatedMergeTreeQueue::SelectedEntryPtr)::(anonymous class)::operator()(LogEntryPtr &) const: Code: 86. DB::HTTPException: Received error from remote server http://146b4357c08d:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Ftest%2F01165%2Ftest_13%2Frmt%2Freplicas%2F1&part=20250728_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.6.10636.altinitytest (altinity build)) '. (RECEIVED_ERROR_FROM_REMOTE_IO_SERVER), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.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 const&, int&&, String const&, unsigned long&&, String const&) @ 0x000000000feda8d9 4. /build/src/IO/HTTPCommon.cpp:104: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x000000000feda6e2 5. /build/src/IO/HTTPCommon.cpp:93: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x000000000feda537 6. /build/src/IO/ReadWriteBufferFromHTTP.cpp:277: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x000000001184a4c4 7. /build/src/IO/ReadWriteBufferFromHTTP.cpp:285: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x000000001184a615 8. /build/src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x000000001184ae59 9. /build/src/IO/ReadWriteBufferFromHTTP.cpp:472: void std::__function::__policy_invoker::__call_impl[abi:se190107]>(std::__function::__policy_storage const*) @ 0x000000001184cedd 10. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001184858b 11. /build/src/IO/ReadWriteBufferFromHTTP.cpp:465: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x000000001184bf0b 12. /build/src/IO/ReadBuffer.h:60: DB::ReadBuffer::next() @ 0x000000000a148c7b 13. /build/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) @ 0x0000000011849fb2 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]>&)>&, 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&) @ 0x0000000011841980 15. /build/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) @ 0x000000001621208e 16. /build/src/Storages/StorageReplicatedMergeTree.cpp:5228: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl[abi:se190107] const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000015f9a5fe 17. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000015ed8bfd 18. /build/src/Storages/StorageReplicatedMergeTree.cpp:2514: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x0000000015ec9aab 19. /build/src/Storages/StorageReplicatedMergeTree.cpp:2349: DB::StorageReplicatedMergeTree::executeLogEntry(DB::ReplicatedMergeTreeLogEntry&) @ 0x0000000015eba91b 20. /build/src/Storages/StorageReplicatedMergeTree.cpp:3876: bool std::__function::__policy_invoker&)>::__call_impl[abi:se190107])::$_1, bool (std::shared_ptr&)>>(std::__function::__policy_storage const*, std::shared_ptr&) @ 0x0000000015f9837e 21. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000165d6fc3 22. /build/src/Storages/StorageReplicatedMergeTree.cpp:3872: DB::StorageReplicatedMergeTree::processQueueEntry(std::shared_ptr) @ 0x0000000015efc18a 23. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001624c1b2 24. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000162f9c70 25. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x00000000162fa55a 26. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc6653 27. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000000fccc4c3 28. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc3d92 29. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fcca080 30. ? @ 0x00007fbc6213eac3 31. ? @ 0x00007fbc621d0850 (version 25.3.6.10636.altinitytest (altinity build)) 2025.07.28 11:56:16.417001 [ 3960 ] {} test_13.rmt2 (7f9b740d-015c-470e-8cc6-8ba33be0dc63): auto DB::StorageReplicatedMergeTree::processQueueEntry(ReplicatedMergeTreeQueue::SelectedEntryPtr)::(anonymous class)::operator()(LogEntryPtr &) const: Code: 86. DB::HTTPException: Received error from remote server http://146b4357c08d:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Ftest%2F01165%2Ftest_13%2Frmt%2Freplicas%2F1&part=20250728_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.6.10636.altinitytest (altinity build)) '. (RECEIVED_ERROR_FROM_REMOTE_IO_SERVER), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.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 const&, int&&, String const&, unsigned long&&, String const&) @ 0x000000000feda8d9 4. /build/src/IO/HTTPCommon.cpp:104: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x000000000feda6e2 5. /build/src/IO/HTTPCommon.cpp:93: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x000000000feda537 6. /build/src/IO/ReadWriteBufferFromHTTP.cpp:277: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x000000001184a4c4 7. /build/src/IO/ReadWriteBufferFromHTTP.cpp:285: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x000000001184a615 8. /build/src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x000000001184ae59 9. /build/src/IO/ReadWriteBufferFromHTTP.cpp:472: void std::__function::__policy_invoker::__call_impl[abi:se190107]>(std::__function::__policy_storage const*) @ 0x000000001184cedd 10. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001184858b 11. /build/src/IO/ReadWriteBufferFromHTTP.cpp:465: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x000000001184bf0b 12. /build/src/IO/ReadBuffer.h:60: DB::ReadBuffer::next() @ 0x000000000a148c7b 13. /build/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) @ 0x0000000011849fb2 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]>&)>&, 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&) @ 0x0000000011841980 15. /build/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) @ 0x000000001621208e 16. /build/src/Storages/StorageReplicatedMergeTree.cpp:5228: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl[abi:se190107] const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000015f9a5fe 17. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000015ed8bfd 18. /build/src/Storages/StorageReplicatedMergeTree.cpp:2514: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x0000000015ec9aab 19. /build/src/Storages/StorageReplicatedMergeTree.cpp:2349: DB::StorageReplicatedMergeTree::executeLogEntry(DB::ReplicatedMergeTreeLogEntry&) @ 0x0000000015eba91b 20. /build/src/Storages/StorageReplicatedMergeTree.cpp:3876: bool std::__function::__policy_invoker&)>::__call_impl[abi:se190107])::$_1, bool (std::shared_ptr&)>>(std::__function::__policy_storage const*, std::shared_ptr&) @ 0x0000000015f9837e 21. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000165d6fc3 22. /build/src/Storages/StorageReplicatedMergeTree.cpp:3872: DB::StorageReplicatedMergeTree::processQueueEntry(std::shared_ptr) @ 0x0000000015efc18a 23. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001624c1b2 24. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000162f9c70 25. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x00000000162fa55a 26. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc6653 27. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000000fccc4c3 28. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc3d92 29. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fcca080 30. ? @ 0x00007fbc6213eac3 31. ? @ 0x00007fbc621d0850 (version 25.3.6.10636.altinitytest (altinity build)) 2025.07.28 11:56:16.727985 [ 3965 ] {} test_13.rmt2 (7f9b740d-015c-470e-8cc6-8ba33be0dc63): auto DB::StorageReplicatedMergeTree::processQueueEntry(ReplicatedMergeTreeQueue::SelectedEntryPtr)::(anonymous class)::operator()(LogEntryPtr &) const: Code: 86. DB::HTTPException: Received error from remote server http://146b4357c08d:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Ftest%2F01165%2Ftest_13%2Frmt%2Freplicas%2F1&part=20250728_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.6.10636.altinitytest (altinity build)) '. (RECEIVED_ERROR_FROM_REMOTE_IO_SERVER), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.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 const&, int&&, String const&, unsigned long&&, String const&) @ 0x000000000feda8d9 4. /build/src/IO/HTTPCommon.cpp:104: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x000000000feda6e2 5. /build/src/IO/HTTPCommon.cpp:93: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x000000000feda537 6. /build/src/IO/ReadWriteBufferFromHTTP.cpp:277: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x000000001184a4c4 7. /build/src/IO/ReadWriteBufferFromHTTP.cpp:285: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x000000001184a615 8. /build/src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x000000001184ae59 9. /build/src/IO/ReadWriteBufferFromHTTP.cpp:472: void std::__function::__policy_invoker::__call_impl[abi:se190107]>(std::__function::__policy_storage const*) @ 0x000000001184cedd 10. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001184858b 11. /build/src/IO/ReadWriteBufferFromHTTP.cpp:465: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x000000001184bf0b 12. /build/src/IO/ReadBuffer.h:60: DB::ReadBuffer::next() @ 0x000000000a148c7b 13. /build/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) @ 0x0000000011849fb2 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]>&)>&, 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&) @ 0x0000000011841980 15. /build/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) @ 0x000000001621208e 16. /build/src/Storages/StorageReplicatedMergeTree.cpp:5228: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl[abi:se190107] const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000015f9a5fe 17. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000015ed8bfd 18. /build/src/Storages/StorageReplicatedMergeTree.cpp:2514: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x0000000015ec9aab 19. /build/src/Storages/StorageReplicatedMergeTree.cpp:2349: DB::StorageReplicatedMergeTree::executeLogEntry(DB::ReplicatedMergeTreeLogEntry&) @ 0x0000000015eba91b 20. /build/src/Storages/StorageReplicatedMergeTree.cpp:3876: bool std::__function::__policy_invoker&)>::__call_impl[abi:se190107])::$_1, bool (std::shared_ptr&)>>(std::__function::__policy_storage const*, std::shared_ptr&) @ 0x0000000015f9837e 21. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000165d6fc3 22. /build/src/Storages/StorageReplicatedMergeTree.cpp:3872: DB::StorageReplicatedMergeTree::processQueueEntry(std::shared_ptr) @ 0x0000000015efc18a 23. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001624c1b2 24. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000162f9c70 25. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x00000000162fa55a 26. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc6653 27. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000000fccc4c3 28. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc3d92 29. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fcca080 30. ? @ 0x00007fbc6213eac3 31. ? @ 0x00007fbc621d0850 (version 25.3.6.10636.altinitytest (altinity build)) 2025.07.28 11:56:17.492507 [ 3976 ] {} test_13.rmt2 (7f9b740d-015c-470e-8cc6-8ba33be0dc63): auto DB::StorageReplicatedMergeTree::processQueueEntry(ReplicatedMergeTreeQueue::SelectedEntryPtr)::(anonymous class)::operator()(LogEntryPtr &) const: Code: 86. DB::HTTPException: Received error from remote server http://146b4357c08d:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Ftest%2F01165%2Ftest_13%2Frmt%2Freplicas%2F1&part=20250728_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.6.10636.altinitytest (altinity build)) '. (RECEIVED_ERROR_FROM_REMOTE_IO_SERVER), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.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 const&, int&&, String const&, unsigned long&&, String const&) @ 0x000000000feda8d9 4. /build/src/IO/HTTPCommon.cpp:104: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x000000000feda6e2 5. /build/src/IO/HTTPCommon.cpp:93: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x000000000feda537 6. /build/src/IO/ReadWriteBufferFromHTTP.cpp:277: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x000000001184a4c4 7. /build/src/IO/ReadWriteBufferFromHTTP.cpp:285: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x000000001184a615 8. /build/src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x000000001184ae59 9. /build/src/IO/ReadWriteBufferFromHTTP.cpp:472: void std::__function::__policy_invoker::__call_impl[abi:se190107]>(std::__function::__policy_storage const*) @ 0x000000001184cedd 10. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001184858b 11. /build/src/IO/ReadWriteBufferFromHTTP.cpp:465: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x000000001184bf0b 12. /build/src/IO/ReadBuffer.h:60: DB::ReadBuffer::next() @ 0x000000000a148c7b 13. /build/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) @ 0x0000000011849fb2 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]>&)>&, 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&) @ 0x0000000011841980 15. /build/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) @ 0x000000001621208e 16. /build/src/Storages/StorageReplicatedMergeTree.cpp:5228: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl[abi:se190107] const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000015f9a5fe 17. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000015ed8bfd 18. /build/src/Storages/StorageReplicatedMergeTree.cpp:2514: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x0000000015ec9aab 19. /build/src/Storages/StorageReplicatedMergeTree.cpp:2349: DB::StorageReplicatedMergeTree::executeLogEntry(DB::ReplicatedMergeTreeLogEntry&) @ 0x0000000015eba91b 20. /build/src/Storages/StorageReplicatedMergeTree.cpp:3876: bool std::__function::__policy_invoker&)>::__call_impl[abi:se190107])::$_1, bool (std::shared_ptr&)>>(std::__function::__policy_storage const*, std::shared_ptr&) @ 0x0000000015f9837e 21. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000165d6fc3 22. /build/src/Storages/StorageReplicatedMergeTree.cpp:3872: DB::StorageReplicatedMergeTree::processQueueEntry(std::shared_ptr) @ 0x0000000015efc18a 23. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001624c1b2 24. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000162f9c70 25. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x00000000162fa55a 26. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc6653 27. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000000fccc4c3 28. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc3d92 29. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fcca080 30. ? @ 0x00007fbc6213eac3 31. ? @ 0x00007fbc621d0850 (version 25.3.6.10636.altinitytest (altinity build)) 2025.07.28 11:56:18.357048 [ 3972 ] {} test_13.rmt2 (7f9b740d-015c-470e-8cc6-8ba33be0dc63): auto DB::StorageReplicatedMergeTree::processQueueEntry(ReplicatedMergeTreeQueue::SelectedEntryPtr)::(anonymous class)::operator()(LogEntryPtr &) const: Code: 86. DB::HTTPException: Received error from remote server http://146b4357c08d:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Ftest%2F01165%2Ftest_13%2Frmt%2Freplicas%2F1&part=20250728_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.6.10636.altinitytest (altinity build)) '. (RECEIVED_ERROR_FROM_REMOTE_IO_SERVER), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.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 const&, int&&, String const&, unsigned long&&, String const&) @ 0x000000000feda8d9 4. /build/src/IO/HTTPCommon.cpp:104: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x000000000feda6e2 5. /build/src/IO/HTTPCommon.cpp:93: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x000000000feda537 6. /build/src/IO/ReadWriteBufferFromHTTP.cpp:277: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x000000001184a4c4 7. /build/src/IO/ReadWriteBufferFromHTTP.cpp:285: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x000000001184a615 8. /build/src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x000000001184ae59 9. /build/src/IO/ReadWriteBufferFromHTTP.cpp:472: void std::__function::__policy_invoker::__call_impl[abi:se190107]>(std::__function::__policy_storage const*) @ 0x000000001184cedd 10. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001184858b 11. /build/src/IO/ReadWriteBufferFromHTTP.cpp:465: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x000000001184bf0b 12. /build/src/IO/ReadBuffer.h:60: DB::ReadBuffer::next() @ 0x000000000a148c7b 13. /build/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) @ 0x0000000011849fb2 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]>&)>&, 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&) @ 0x0000000011841980 15. /build/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) @ 0x000000001621208e 16. /build/src/Storages/StorageReplicatedMergeTree.cpp:5228: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl[abi:se190107] const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000015f9a5fe 17. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000015ed8bfd 18. /build/src/Storages/StorageReplicatedMergeTree.cpp:2514: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x0000000015ec9aab 19. /build/src/Storages/StorageReplicatedMergeTree.cpp:2349: DB::StorageReplicatedMergeTree::executeLogEntry(DB::ReplicatedMergeTreeLogEntry&) @ 0x0000000015eba91b 20. /build/src/Storages/StorageReplicatedMergeTree.cpp:3876: bool std::__function::__policy_invoker&)>::__call_impl[abi:se190107])::$_1, bool (std::shared_ptr&)>>(std::__function::__policy_storage const*, std::shared_ptr&) @ 0x0000000015f9837e 21. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000165d6fc3 22. /build/src/Storages/StorageReplicatedMergeTree.cpp:3872: DB::StorageReplicatedMergeTree::processQueueEntry(std::shared_ptr) @ 0x0000000015efc18a 23. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001624c1b2 24. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000162f9c70 25. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x00000000162fa55a 26. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc6653 27. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000000fccc4c3 28. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc3d92 29. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fcca080 30. ? @ 0x00007fbc6213eac3 31. ? @ 0x00007fbc621d0850 (version 25.3.6.10636.altinitytest (altinity build)) 2025.07.28 11:56:19.261202 [ 3963 ] {} test_13.rmt2 (7f9b740d-015c-470e-8cc6-8ba33be0dc63): auto DB::StorageReplicatedMergeTree::processQueueEntry(ReplicatedMergeTreeQueue::SelectedEntryPtr)::(anonymous class)::operator()(LogEntryPtr &) const: Code: 86. DB::HTTPException: Received error from remote server http://146b4357c08d:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Ftest%2F01165%2Ftest_13%2Frmt%2Freplicas%2F1&part=20250728_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.6.10636.altinitytest (altinity build)) '. (RECEIVED_ERROR_FROM_REMOTE_IO_SERVER), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.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 const&, int&&, String const&, unsigned long&&, String const&) @ 0x000000000feda8d9 4. /build/src/IO/HTTPCommon.cpp:104: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x000000000feda6e2 5. /build/src/IO/HTTPCommon.cpp:93: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x000000000feda537 6. /build/src/IO/ReadWriteBufferFromHTTP.cpp:277: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x000000001184a4c4 7. /build/src/IO/ReadWriteBufferFromHTTP.cpp:285: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x000000001184a615 8. /build/src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x000000001184ae59 9. /build/src/IO/ReadWriteBufferFromHTTP.cpp:472: void std::__function::__policy_invoker::__call_impl[abi:se190107]>(std::__function::__policy_storage const*) @ 0x000000001184cedd 10. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001184858b 11. /build/src/IO/ReadWriteBufferFromHTTP.cpp:465: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x000000001184bf0b 12. /build/src/IO/ReadBuffer.h:60: DB::ReadBuffer::next() @ 0x000000000a148c7b 13. /build/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) @ 0x0000000011849fb2 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]>&)>&, 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&) @ 0x0000000011841980 15. /build/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) @ 0x000000001621208e 16. /build/src/Storages/StorageReplicatedMergeTree.cpp:5228: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl[abi:se190107] const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000015f9a5fe 17. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000015ed8bfd 18. /build/src/Storages/StorageReplicatedMergeTree.cpp:2514: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x0000000015ec9aab 19. /build/src/Storages/StorageReplicatedMergeTree.cpp:2349: DB::StorageReplicatedMergeTree::executeLogEntry(DB::ReplicatedMergeTreeLogEntry&) @ 0x0000000015eba91b 20. /build/src/Storages/StorageReplicatedMergeTree.cpp:3876: bool std::__function::__policy_invoker&)>::__call_impl[abi:se190107])::$_1, bool (std::shared_ptr&)>>(std::__function::__policy_storage const*, std::shared_ptr&) @ 0x0000000015f9837e 21. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000165d6fc3 22. /build/src/Storages/StorageReplicatedMergeTree.cpp:3872: DB::StorageReplicatedMergeTree::processQueueEntry(std::shared_ptr) @ 0x0000000015efc18a 23. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001624c1b2 24. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000162f9c70 25. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x00000000162fa55a 26. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc6653 27. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000000fccc4c3 28. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc3d92 29. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fcca080 30. ? @ 0x00007fbc6213eac3 31. ? @ 0x00007fbc621d0850 (version 25.3.6.10636.altinitytest (altinity build)) 2025.07.28 11:56:20.037543 [ 3965 ] {} test_13.rmt2 (7f9b740d-015c-470e-8cc6-8ba33be0dc63): auto DB::StorageReplicatedMergeTree::processQueueEntry(ReplicatedMergeTreeQueue::SelectedEntryPtr)::(anonymous class)::operator()(LogEntryPtr &) const: Code: 86. DB::HTTPException: Received error from remote server http://146b4357c08d:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Ftest%2F01165%2Ftest_13%2Frmt%2Freplicas%2F1&part=20250728_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.6.10636.altinitytest (altinity build)) '. (RECEIVED_ERROR_FROM_REMOTE_IO_SERVER), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.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 const&, int&&, String const&, unsigned long&&, String const&) @ 0x000000000feda8d9 4. /build/src/IO/HTTPCommon.cpp:104: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x000000000feda6e2 5. /build/src/IO/HTTPCommon.cpp:93: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x000000000feda537 6. /build/src/IO/ReadWriteBufferFromHTTP.cpp:277: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x000000001184a4c4 7. /build/src/IO/ReadWriteBufferFromHTTP.cpp:285: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x000000001184a615 8. /build/src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x000000001184ae59 9. /build/src/IO/ReadWriteBufferFromHTTP.cpp:472: void std::__function::__policy_invoker::__call_impl[abi:se190107]>(std::__function::__policy_storage const*) @ 0x000000001184cedd 10. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001184858b 11. /build/src/IO/ReadWriteBufferFromHTTP.cpp:465: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x000000001184bf0b 12. /build/src/IO/ReadBuffer.h:60: DB::ReadBuffer::next() @ 0x000000000a148c7b 13. /build/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) @ 0x0000000011849fb2 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]>&)>&, 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&) @ 0x0000000011841980 15. /build/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) @ 0x000000001621208e 16. /build/src/Storages/StorageReplicatedMergeTree.cpp:5228: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl[abi:se190107] const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000015f9a5fe 17. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000015ed8bfd 18. /build/src/Storages/StorageReplicatedMergeTree.cpp:2514: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x0000000015ec9aab 19. /build/src/Storages/StorageReplicatedMergeTree.cpp:2349: DB::StorageReplicatedMergeTree::executeLogEntry(DB::ReplicatedMergeTreeLogEntry&) @ 0x0000000015eba91b 20. /build/src/Storages/StorageReplicatedMergeTree.cpp:3876: bool std::__function::__policy_invoker&)>::__call_impl[abi:se190107])::$_1, bool (std::shared_ptr&)>>(std::__function::__policy_storage const*, std::shared_ptr&) @ 0x0000000015f9837e 21. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000165d6fc3 22. /build/src/Storages/StorageReplicatedMergeTree.cpp:3872: DB::StorageReplicatedMergeTree::processQueueEntry(std::shared_ptr) @ 0x0000000015efc18a 23. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001624c1b2 24. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000162f9c70 25. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x00000000162fa55a 26. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc6653 27. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000000fccc4c3 28. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc3d92 29. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fcca080 30. ? @ 0x00007fbc6213eac3 31. ? @ 0x00007fbc621d0850 (version 25.3.6.10636.altinitytest (altinity build)) 2025.07.28 11:56:21.072299 [ 3961 ] {} test_13.rmt2 (7f9b740d-015c-470e-8cc6-8ba33be0dc63): auto DB::StorageReplicatedMergeTree::processQueueEntry(ReplicatedMergeTreeQueue::SelectedEntryPtr)::(anonymous class)::operator()(LogEntryPtr &) const: Code: 86. DB::HTTPException: Received error from remote server http://146b4357c08d:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Ftest%2F01165%2Ftest_13%2Frmt%2Freplicas%2F1&part=20250728_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.6.10636.altinitytest (altinity build)) '. (RECEIVED_ERROR_FROM_REMOTE_IO_SERVER), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.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 const&, int&&, String const&, unsigned long&&, String const&) @ 0x000000000feda8d9 4. /build/src/IO/HTTPCommon.cpp:104: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x000000000feda6e2 5. /build/src/IO/HTTPCommon.cpp:93: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x000000000feda537 6. /build/src/IO/ReadWriteBufferFromHTTP.cpp:277: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x000000001184a4c4 7. /build/src/IO/ReadWriteBufferFromHTTP.cpp:285: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x000000001184a615 8. /build/src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x000000001184ae59 9. /build/src/IO/ReadWriteBufferFromHTTP.cpp:472: void std::__function::__policy_invoker::__call_impl[abi:se190107]>(std::__function::__policy_storage const*) @ 0x000000001184cedd 10. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001184858b 11. /build/src/IO/ReadWriteBufferFromHTTP.cpp:465: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x000000001184bf0b 12. /build/src/IO/ReadBuffer.h:60: DB::ReadBuffer::next() @ 0x000000000a148c7b 13. /build/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) @ 0x0000000011849fb2 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]>&)>&, 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&) @ 0x0000000011841980 15. /build/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) @ 0x000000001621208e 16. /build/src/Storages/StorageReplicatedMergeTree.cpp:5228: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl[abi:se190107] const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000015f9a5fe 17. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000015ed8bfd 18. /build/src/Storages/StorageReplicatedMergeTree.cpp:2514: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x0000000015ec9aab 19. /build/src/Storages/StorageReplicatedMergeTree.cpp:2349: DB::StorageReplicatedMergeTree::executeLogEntry(DB::ReplicatedMergeTreeLogEntry&) @ 0x0000000015eba91b 20. /build/src/Storages/StorageReplicatedMergeTree.cpp:3876: bool std::__function::__policy_invoker&)>::__call_impl[abi:se190107])::$_1, bool (std::shared_ptr&)>>(std::__function::__policy_storage const*, std::shared_ptr&) @ 0x0000000015f9837e 21. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000165d6fc3 22. /build/src/Storages/StorageReplicatedMergeTree.cpp:3872: DB::StorageReplicatedMergeTree::processQueueEntry(std::shared_ptr) @ 0x0000000015efc18a 23. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001624c1b2 24. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000162f9c70 25. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x00000000162fa55a 26. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc6653 27. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000000fccc4c3 28. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc3d92 29. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fcca080 30. ? @ 0x00007fbc6213eac3 31. ? @ 0x00007fbc621d0850 (version 25.3.6.10636.altinitytest (altinity build)) 2025.07.28 11:56:21.421134 [ 3960 ] {} test_13.rmt2 (7f9b740d-015c-470e-8cc6-8ba33be0dc63): auto DB::StorageReplicatedMergeTree::processQueueEntry(ReplicatedMergeTreeQueue::SelectedEntryPtr)::(anonymous class)::operator()(LogEntryPtr &) const: Code: 86. DB::HTTPException: Received error from remote server http://146b4357c08d:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Ftest%2F01165%2Ftest_13%2Frmt%2Freplicas%2F1&part=20250728_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.6.10636.altinitytest (altinity build)) '. (RECEIVED_ERROR_FROM_REMOTE_IO_SERVER), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.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 const&, int&&, String const&, unsigned long&&, String const&) @ 0x000000000feda8d9 4. /build/src/IO/HTTPCommon.cpp:104: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x000000000feda6e2 5. /build/src/IO/HTTPCommon.cpp:93: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x000000000feda537 6. /build/src/IO/ReadWriteBufferFromHTTP.cpp:277: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x000000001184a4c4 7. /build/src/IO/ReadWriteBufferFromHTTP.cpp:285: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x000000001184a615 8. /build/src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x000000001184ae59 9. /build/src/IO/ReadWriteBufferFromHTTP.cpp:472: void std::__function::__policy_invoker::__call_impl[abi:se190107]>(std::__function::__policy_storage const*) @ 0x000000001184cedd 10. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001184858b 11. /build/src/IO/ReadWriteBufferFromHTTP.cpp:465: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x000000001184bf0b 12. /build/src/IO/ReadBuffer.h:60: DB::ReadBuffer::next() @ 0x000000000a148c7b 13. /build/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) @ 0x0000000011849fb2 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]>&)>&, 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&) @ 0x0000000011841980 15. /build/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) @ 0x000000001621208e 16. /build/src/Storages/StorageReplicatedMergeTree.cpp:5228: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl[abi:se190107] const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000015f9a5fe 17. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000015ed8bfd 18. /build/src/Storages/StorageReplicatedMergeTree.cpp:2514: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x0000000015ec9aab 19. /build/src/Storages/StorageReplicatedMergeTree.cpp:2349: DB::StorageReplicatedMergeTree::executeLogEntry(DB::ReplicatedMergeTreeLogEntry&) @ 0x0000000015eba91b 20. /build/src/Storages/StorageReplicatedMergeTree.cpp:3876: bool std::__function::__policy_invoker&)>::__call_impl[abi:se190107])::$_1, bool (std::shared_ptr&)>>(std::__function::__policy_storage const*, std::shared_ptr&) @ 0x0000000015f9837e 21. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000165d6fc3 22. /build/src/Storages/StorageReplicatedMergeTree.cpp:3872: DB::StorageReplicatedMergeTree::processQueueEntry(std::shared_ptr) @ 0x0000000015efc18a 23. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001624c1b2 24. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000162f9c70 25. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x00000000162fa55a 26. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc6653 27. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000000fccc4c3 28. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc3d92 29. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fcca080 30. ? @ 0x00007fbc6213eac3 31. ? @ 0x00007fbc621d0850 (version 25.3.6.10636.altinitytest (altinity build)) 2025.07.28 11:56:21.957650 [ 3974 ] {} test_13.rmt2 (7f9b740d-015c-470e-8cc6-8ba33be0dc63): auto DB::StorageReplicatedMergeTree::processQueueEntry(ReplicatedMergeTreeQueue::SelectedEntryPtr)::(anonymous class)::operator()(LogEntryPtr &) const: Code: 86. DB::HTTPException: Received error from remote server http://146b4357c08d:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Ftest%2F01165%2Ftest_13%2Frmt%2Freplicas%2F1&part=20250728_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.6.10636.altinitytest (altinity build)) '. (RECEIVED_ERROR_FROM_REMOTE_IO_SERVER), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.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 const&, int&&, String const&, unsigned long&&, String const&) @ 0x000000000feda8d9 4. /build/src/IO/HTTPCommon.cpp:104: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x000000000feda6e2 5. /build/src/IO/HTTPCommon.cpp:93: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x000000000feda537 6. /build/src/IO/ReadWriteBufferFromHTTP.cpp:277: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x000000001184a4c4 7. /build/src/IO/ReadWriteBufferFromHTTP.cpp:285: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x000000001184a615 8. /build/src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x000000001184ae59 9. /build/src/IO/ReadWriteBufferFromHTTP.cpp:472: void std::__function::__policy_invoker::__call_impl[abi:se190107]>(std::__function::__policy_storage const*) @ 0x000000001184cedd 10. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001184858b 11. /build/src/IO/ReadWriteBufferFromHTTP.cpp:465: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x000000001184bf0b 12. /build/src/IO/ReadBuffer.h:60: DB::ReadBuffer::next() @ 0x000000000a148c7b 13. /build/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) @ 0x0000000011849fb2 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]>&)>&, 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&) @ 0x0000000011841980 15. /build/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) @ 0x000000001621208e 16. /build/src/Storages/StorageReplicatedMergeTree.cpp:5228: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl[abi:se190107] const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000015f9a5fe 17. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000015ed8bfd 18. /build/src/Storages/StorageReplicatedMergeTree.cpp:2514: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x0000000015ec9aab 19. /build/src/Storages/StorageReplicatedMergeTree.cpp:2349: DB::StorageReplicatedMergeTree::executeLogEntry(DB::ReplicatedMergeTreeLogEntry&) @ 0x0000000015eba91b 20. /build/src/Storages/StorageReplicatedMergeTree.cpp:3876: bool std::__function::__policy_invoker&)>::__call_impl[abi:se190107])::$_1, bool (std::shared_ptr&)>>(std::__function::__policy_storage const*, std::shared_ptr&) @ 0x0000000015f9837e 21. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000165d6fc3 22. /build/src/Storages/StorageReplicatedMergeTree.cpp:3872: DB::StorageReplicatedMergeTree::processQueueEntry(std::shared_ptr) @ 0x0000000015efc18a 23. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001624c1b2 24. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000162f9c70 25. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x00000000162fa55a 26. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc6653 27. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000000fccc4c3 28. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc3d92 29. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fcca080 30. ? @ 0x00007fbc6213eac3 31. ? @ 0x00007fbc621d0850 (version 25.3.6.10636.altinitytest (altinity build)) 2025.07.28 11:56:22.439497 [ 3967 ] {} test_13.rmt2 (7f9b740d-015c-470e-8cc6-8ba33be0dc63): auto DB::StorageReplicatedMergeTree::processQueueEntry(ReplicatedMergeTreeQueue::SelectedEntryPtr)::(anonymous class)::operator()(LogEntryPtr &) const: Code: 86. DB::HTTPException: Received error from remote server http://146b4357c08d:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Ftest%2F01165%2Ftest_13%2Frmt%2Freplicas%2F1&part=20250728_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.6.10636.altinitytest (altinity build)) '. (RECEIVED_ERROR_FROM_REMOTE_IO_SERVER), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.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 const&, int&&, String const&, unsigned long&&, String const&) @ 0x000000000feda8d9 4. /build/src/IO/HTTPCommon.cpp:104: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x000000000feda6e2 5. /build/src/IO/HTTPCommon.cpp:93: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x000000000feda537 6. /build/src/IO/ReadWriteBufferFromHTTP.cpp:277: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x000000001184a4c4 7. /build/src/IO/ReadWriteBufferFromHTTP.cpp:285: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x000000001184a615 8. /build/src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x000000001184ae59 9. /build/src/IO/ReadWriteBufferFromHTTP.cpp:472: void std::__function::__policy_invoker::__call_impl[abi:se190107]>(std::__function::__policy_storage const*) @ 0x000000001184cedd 10. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001184858b 11. /build/src/IO/ReadWriteBufferFromHTTP.cpp:465: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x000000001184bf0b 12. /build/src/IO/ReadBuffer.h:60: DB::ReadBuffer::next() @ 0x000000000a148c7b 13. /build/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) @ 0x0000000011849fb2 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]>&)>&, 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&) @ 0x0000000011841980 15. /build/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) @ 0x000000001621208e 16. /build/src/Storages/StorageReplicatedMergeTree.cpp:5228: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl[abi:se190107] const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000015f9a5fe 17. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000015ed8bfd 18. /build/src/Storages/StorageReplicatedMergeTree.cpp:2514: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x0000000015ec9aab 19. /build/src/Storages/StorageReplicatedMergeTree.cpp:2349: DB::StorageReplicatedMergeTree::executeLogEntry(DB::ReplicatedMergeTreeLogEntry&) @ 0x0000000015eba91b 20. /build/src/Storages/StorageReplicatedMergeTree.cpp:3876: bool std::__function::__policy_invoker&)>::__call_impl[abi:se190107])::$_1, bool (std::shared_ptr&)>>(std::__function::__policy_storage const*, std::shared_ptr&) @ 0x0000000015f9837e 21. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000165d6fc3 22. /build/src/Storages/StorageReplicatedMergeTree.cpp:3872: DB::StorageReplicatedMergeTree::processQueueEntry(std::shared_ptr) @ 0x0000000015efc18a 23. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001624c1b2 24. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000162f9c70 25. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x00000000162fa55a 26. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc6653 27. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000000fccc4c3 28. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc3d92 29. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fcca080 30. ? @ 0x00007fbc6213eac3 31. ? @ 0x00007fbc621d0850 (version 25.3.6.10636.altinitytest (altinity build)) 2025.07.28 11:56:23.243408 [ 17557 ] {} 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. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception>&, String>(int, FormatStringHelperImpl>&>::type, std::type_identity::type>, std::basic_string_view>&, String&&) @ 0x000000001385a5eb 4. /build/src/Access/SettingsConstraints.cpp:376: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000013859b18 5. /build/src/Access/SettingsConstraints.cpp:300: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000013858faf 6. /build/src/Access/SettingsConstraints.cpp:209: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000013859223 7. /build/src/Interpreters/Context.cpp:2690: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000014436134 8. /build/src/Interpreters/Context.cpp:2729: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x000000001443662b 9. /build/src/Server/HTTPHandler.cpp:457: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000001686d165 10. /build/src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x0000000016870807 11. /build/src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x0000000016907e99 12. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 13. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 14. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 15. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 16. ? @ 0x00007fbc6213eac3 17. ? @ 0x00007fbc621d0850 (version 25.3.6.10636.altinitytest (altinity build)) 2025.07.28 11:56:23.344451 [ 3972 ] {} test_13.rmt2 (7f9b740d-015c-470e-8cc6-8ba33be0dc63): auto DB::StorageReplicatedMergeTree::processQueueEntry(ReplicatedMergeTreeQueue::SelectedEntryPtr)::(anonymous class)::operator()(LogEntryPtr &) const: Code: 86. DB::HTTPException: Received error from remote server http://146b4357c08d:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Ftest%2F01165%2Ftest_13%2Frmt%2Freplicas%2F1&part=20250728_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.6.10636.altinitytest (altinity build)) '. (RECEIVED_ERROR_FROM_REMOTE_IO_SERVER), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.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 const&, int&&, String const&, unsigned long&&, String const&) @ 0x000000000feda8d9 4. /build/src/IO/HTTPCommon.cpp:104: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x000000000feda6e2 5. /build/src/IO/HTTPCommon.cpp:93: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x000000000feda537 6. /build/src/IO/ReadWriteBufferFromHTTP.cpp:277: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x000000001184a4c4 7. /build/src/IO/ReadWriteBufferFromHTTP.cpp:285: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x000000001184a615 8. /build/src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x000000001184ae59 9. /build/src/IO/ReadWriteBufferFromHTTP.cpp:472: void std::__function::__policy_invoker::__call_impl[abi:se190107]>(std::__function::__policy_storage const*) @ 0x000000001184cedd 10. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001184858b 11. /build/src/IO/ReadWriteBufferFromHTTP.cpp:465: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x000000001184bf0b 12. /build/src/IO/ReadBuffer.h:60: DB::ReadBuffer::next() @ 0x000000000a148c7b 13. /build/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) @ 0x0000000011849fb2 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]>&)>&, 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&) @ 0x0000000011841980 15. /build/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) @ 0x000000001621208e 16. /build/src/Storages/StorageReplicatedMergeTree.cpp:5228: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl[abi:se190107] const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000015f9a5fe 17. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000015ed8bfd 18. /build/src/Storages/StorageReplicatedMergeTree.cpp:2514: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x0000000015ec9aab 19. /build/src/Storages/StorageReplicatedMergeTree.cpp:2349: DB::StorageReplicatedMergeTree::executeLogEntry(DB::ReplicatedMergeTreeLogEntry&) @ 0x0000000015eba91b 20. /build/src/Storages/StorageReplicatedMergeTree.cpp:3876: bool std::__function::__policy_invoker&)>::__call_impl[abi:se190107])::$_1, bool (std::shared_ptr&)>>(std::__function::__policy_storage const*, std::shared_ptr&) @ 0x0000000015f9837e 21. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000165d6fc3 22. /build/src/Storages/StorageReplicatedMergeTree.cpp:3872: DB::StorageReplicatedMergeTree::processQueueEntry(std::shared_ptr) @ 0x0000000015efc18a 23. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001624c1b2 24. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000162f9c70 25. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x00000000162fa55a 26. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc6653 27. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000000fccc4c3 28. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc3d92 29. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fcca080 30. ? @ 0x00007fbc6213eac3 31. ? @ 0x00007fbc621d0850 (version 25.3.6.10636.altinitytest (altinity build)) 2025.07.28 11:56:23.392276 [ 4581 ] {} TCPHandler: Code: 394. DB::Exception: Query '93874492-bf30-4106-8414-76fc7b4d8ad4' is killed in pending state. (QUERY_WAS_CANCELLED), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x000000000a06b56b 4. /build/src/Interpreters/executeQuery.cpp:1522: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c8a4ef 5. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 6. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 7. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 8. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 9. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 10. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 11. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 12. ? @ 0x00007fbc6213eac3 13. ? @ 0x00007fbc621d0850 2025.07.28 11:56:23.747433 [ 3967 ] {} test_13.rmt2 (7f9b740d-015c-470e-8cc6-8ba33be0dc63): auto DB::StorageReplicatedMergeTree::processQueueEntry(ReplicatedMergeTreeQueue::SelectedEntryPtr)::(anonymous class)::operator()(LogEntryPtr &) const: Code: 86. DB::HTTPException: Received error from remote server http://146b4357c08d:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Ftest%2F01165%2Ftest_13%2Frmt%2Freplicas%2F1&part=20250728_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.6.10636.altinitytest (altinity build)) '. (RECEIVED_ERROR_FROM_REMOTE_IO_SERVER), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.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 const&, int&&, String const&, unsigned long&&, String const&) @ 0x000000000feda8d9 4. /build/src/IO/HTTPCommon.cpp:104: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x000000000feda6e2 5. /build/src/IO/HTTPCommon.cpp:93: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x000000000feda537 6. /build/src/IO/ReadWriteBufferFromHTTP.cpp:277: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x000000001184a4c4 7. /build/src/IO/ReadWriteBufferFromHTTP.cpp:285: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x000000001184a615 8. /build/src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x000000001184ae59 9. /build/src/IO/ReadWriteBufferFromHTTP.cpp:472: void std::__function::__policy_invoker::__call_impl[abi:se190107]>(std::__function::__policy_storage const*) @ 0x000000001184cedd 10. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001184858b 11. /build/src/IO/ReadWriteBufferFromHTTP.cpp:465: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x000000001184bf0b 12. /build/src/IO/ReadBuffer.h:60: DB::ReadBuffer::next() @ 0x000000000a148c7b 13. /build/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) @ 0x0000000011849fb2 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]>&)>&, 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&) @ 0x0000000011841980 15. /build/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) @ 0x000000001621208e 16. /build/src/Storages/StorageReplicatedMergeTree.cpp:5228: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl[abi:se190107] const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000015f9a5fe 17. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000015ed8bfd 18. /build/src/Storages/StorageReplicatedMergeTree.cpp:2514: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x0000000015ec9aab 19. /build/src/Storages/StorageReplicatedMergeTree.cpp:2349: DB::StorageReplicatedMergeTree::executeLogEntry(DB::ReplicatedMergeTreeLogEntry&) @ 0x0000000015eba91b 20. /build/src/Storages/StorageReplicatedMergeTree.cpp:3876: bool std::__function::__policy_invoker&)>::__call_impl[abi:se190107])::$_1, bool (std::shared_ptr&)>>(std::__function::__policy_storage const*, std::shared_ptr&) @ 0x0000000015f9837e 21. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000165d6fc3 22. /build/src/Storages/StorageReplicatedMergeTree.cpp:3872: DB::StorageReplicatedMergeTree::processQueueEntry(std::shared_ptr) @ 0x0000000015efc18a 23. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001624c1b2 24. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000162f9c70 25. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x00000000162fa55a 26. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc6653 27. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000000fccc4c3 28. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc3d92 29. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fcca080 30. ? @ 0x00007fbc6213eac3 31. ? @ 0x00007fbc621d0850 (version 25.3.6.10636.altinitytest (altinity build)) 2025.07.28 11:56:24.384803 [ 3285 ] {} 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. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception>&, String>(int, FormatStringHelperImpl>&>::type, std::type_identity::type>, std::basic_string_view>&, String&&) @ 0x000000001385a5eb 4. /build/src/Access/SettingsConstraints.cpp:376: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000013859b18 5. /build/src/Access/SettingsConstraints.cpp:300: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000013858faf 6. /build/src/Access/SettingsConstraints.cpp:209: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000013859223 7. /build/src/Interpreters/Context.cpp:2690: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000014436134 8. /build/src/Interpreters/Context.cpp:2729: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x000000001443662b 9. /build/src/Server/HTTPHandler.cpp:457: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000001686d165 10. /build/src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x0000000016870807 11. /build/src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x0000000016907e99 12. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 13. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 14. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 15. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 16. ? @ 0x00007fbc6213eac3 17. ? @ 0x00007fbc621d0850 (version 25.3.6.10636.altinitytest (altinity build)) 2025.07.28 11:56:24.697357 [ 3964 ] {} test_13.rmt2 (7f9b740d-015c-470e-8cc6-8ba33be0dc63): auto DB::StorageReplicatedMergeTree::processQueueEntry(ReplicatedMergeTreeQueue::SelectedEntryPtr)::(anonymous class)::operator()(LogEntryPtr &) const: Code: 86. DB::HTTPException: Received error from remote server http://146b4357c08d:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Ftest%2F01165%2Ftest_13%2Frmt%2Freplicas%2F1&part=20250728_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.6.10636.altinitytest (altinity build)) '. (RECEIVED_ERROR_FROM_REMOTE_IO_SERVER), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.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 const&, int&&, String const&, unsigned long&&, String const&) @ 0x000000000feda8d9 4. /build/src/IO/HTTPCommon.cpp:104: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x000000000feda6e2 5. /build/src/IO/HTTPCommon.cpp:93: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x000000000feda537 6. /build/src/IO/ReadWriteBufferFromHTTP.cpp:277: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x000000001184a4c4 7. /build/src/IO/ReadWriteBufferFromHTTP.cpp:285: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x000000001184a615 8. /build/src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x000000001184ae59 9. /build/src/IO/ReadWriteBufferFromHTTP.cpp:472: void std::__function::__policy_invoker::__call_impl[abi:se190107]>(std::__function::__policy_storage const*) @ 0x000000001184cedd 10. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001184858b 11. /build/src/IO/ReadWriteBufferFromHTTP.cpp:465: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x000000001184bf0b 12. /build/src/IO/ReadBuffer.h:60: DB::ReadBuffer::next() @ 0x000000000a148c7b 13. /build/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) @ 0x0000000011849fb2 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]>&)>&, 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&) @ 0x0000000011841980 15. /build/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) @ 0x000000001621208e 16. /build/src/Storages/StorageReplicatedMergeTree.cpp:5228: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl[abi:se190107] const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000015f9a5fe 17. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000015ed8bfd 18. /build/src/Storages/StorageReplicatedMergeTree.cpp:2514: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x0000000015ec9aab 19. /build/src/Storages/StorageReplicatedMergeTree.cpp:2349: DB::StorageReplicatedMergeTree::executeLogEntry(DB::ReplicatedMergeTreeLogEntry&) @ 0x0000000015eba91b 20. /build/src/Storages/StorageReplicatedMergeTree.cpp:3876: bool std::__function::__policy_invoker&)>::__call_impl[abi:se190107])::$_1, bool (std::shared_ptr&)>>(std::__function::__policy_storage const*, std::shared_ptr&) @ 0x0000000015f9837e 21. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000165d6fc3 22. /build/src/Storages/StorageReplicatedMergeTree.cpp:3872: DB::StorageReplicatedMergeTree::processQueueEntry(std::shared_ptr) @ 0x0000000015efc18a 23. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001624c1b2 24. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000162f9c70 25. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x00000000162fa55a 26. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc6653 27. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000000fccc4c3 28. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc3d92 29. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fcca080 30. ? @ 0x00007fbc6213eac3 31. ? @ 0x00007fbc621d0850 (version 25.3.6.10636.altinitytest (altinity build)) 2025.07.28 11:56:25.064541 [ 3968 ] {} test_13.rmt2 (7f9b740d-015c-470e-8cc6-8ba33be0dc63): auto DB::StorageReplicatedMergeTree::processQueueEntry(ReplicatedMergeTreeQueue::SelectedEntryPtr)::(anonymous class)::operator()(LogEntryPtr &) const: Code: 86. DB::HTTPException: Received error from remote server http://146b4357c08d:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Ftest%2F01165%2Ftest_13%2Frmt%2Freplicas%2F1&part=20250728_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.6.10636.altinitytest (altinity build)) '. (RECEIVED_ERROR_FROM_REMOTE_IO_SERVER), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.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 const&, int&&, String const&, unsigned long&&, String const&) @ 0x000000000feda8d9 4. /build/src/IO/HTTPCommon.cpp:104: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x000000000feda6e2 5. /build/src/IO/HTTPCommon.cpp:93: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x000000000feda537 6. /build/src/IO/ReadWriteBufferFromHTTP.cpp:277: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x000000001184a4c4 7. /build/src/IO/ReadWriteBufferFromHTTP.cpp:285: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x000000001184a615 8. /build/src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x000000001184ae59 9. /build/src/IO/ReadWriteBufferFromHTTP.cpp:472: void std::__function::__policy_invoker::__call_impl[abi:se190107]>(std::__function::__policy_storage const*) @ 0x000000001184cedd 10. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001184858b 11. /build/src/IO/ReadWriteBufferFromHTTP.cpp:465: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x000000001184bf0b 12. /build/src/IO/ReadBuffer.h:60: DB::ReadBuffer::next() @ 0x000000000a148c7b 13. /build/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) @ 0x0000000011849fb2 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]>&)>&, 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&) @ 0x0000000011841980 15. /build/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) @ 0x000000001621208e 16. /build/src/Storages/StorageReplicatedMergeTree.cpp:5228: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl[abi:se190107] const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000015f9a5fe 17. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000015ed8bfd 18. /build/src/Storages/StorageReplicatedMergeTree.cpp:2514: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x0000000015ec9aab 19. /build/src/Storages/StorageReplicatedMergeTree.cpp:2349: DB::StorageReplicatedMergeTree::executeLogEntry(DB::ReplicatedMergeTreeLogEntry&) @ 0x0000000015eba91b 20. /build/src/Storages/StorageReplicatedMergeTree.cpp:3876: bool std::__function::__policy_invoker&)>::__call_impl[abi:se190107])::$_1, bool (std::shared_ptr&)>>(std::__function::__policy_storage const*, std::shared_ptr&) @ 0x0000000015f9837e 21. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000165d6fc3 22. /build/src/Storages/StorageReplicatedMergeTree.cpp:3872: DB::StorageReplicatedMergeTree::processQueueEntry(std::shared_ptr) @ 0x0000000015efc18a 23. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001624c1b2 24. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000162f9c70 25. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x00000000162fa55a 26. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc6653 27. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000000fccc4c3 28. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc3d92 29. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fcca080 30. ? @ 0x00007fbc6213eac3 31. ? @ 0x00007fbc621d0850 (version 25.3.6.10636.altinitytest (altinity build)) 2025.07.28 11:56:25.573808 [ 3976 ] {} test_13.rmt2 (7f9b740d-015c-470e-8cc6-8ba33be0dc63): auto DB::StorageReplicatedMergeTree::processQueueEntry(ReplicatedMergeTreeQueue::SelectedEntryPtr)::(anonymous class)::operator()(LogEntryPtr &) const: Code: 86. DB::HTTPException: Received error from remote server http://146b4357c08d:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Ftest%2F01165%2Ftest_13%2Frmt%2Freplicas%2F1&part=20250728_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.6.10636.altinitytest (altinity build)) '. (RECEIVED_ERROR_FROM_REMOTE_IO_SERVER), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.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 const&, int&&, String const&, unsigned long&&, String const&) @ 0x000000000feda8d9 4. /build/src/IO/HTTPCommon.cpp:104: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x000000000feda6e2 5. /build/src/IO/HTTPCommon.cpp:93: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x000000000feda537 6. /build/src/IO/ReadWriteBufferFromHTTP.cpp:277: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x000000001184a4c4 7. /build/src/IO/ReadWriteBufferFromHTTP.cpp:285: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x000000001184a615 8. /build/src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x000000001184ae59 9. /build/src/IO/ReadWriteBufferFromHTTP.cpp:472: void std::__function::__policy_invoker::__call_impl[abi:se190107]>(std::__function::__policy_storage const*) @ 0x000000001184cedd 10. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001184858b 11. /build/src/IO/ReadWriteBufferFromHTTP.cpp:465: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x000000001184bf0b 12. /build/src/IO/ReadBuffer.h:60: DB::ReadBuffer::next() @ 0x000000000a148c7b 13. /build/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) @ 0x0000000011849fb2 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]>&)>&, 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&) @ 0x0000000011841980 15. /build/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) @ 0x000000001621208e 16. /build/src/Storages/StorageReplicatedMergeTree.cpp:5228: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl[abi:se190107] const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000015f9a5fe 17. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000015ed8bfd 18. /build/src/Storages/StorageReplicatedMergeTree.cpp:2514: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x0000000015ec9aab 19. /build/src/Storages/StorageReplicatedMergeTree.cpp:2349: DB::StorageReplicatedMergeTree::executeLogEntry(DB::ReplicatedMergeTreeLogEntry&) @ 0x0000000015eba91b 20. /build/src/Storages/StorageReplicatedMergeTree.cpp:3876: bool std::__function::__policy_invoker&)>::__call_impl[abi:se190107])::$_1, bool (std::shared_ptr&)>>(std::__function::__policy_storage const*, std::shared_ptr&) @ 0x0000000015f9837e 21. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000165d6fc3 22. /build/src/Storages/StorageReplicatedMergeTree.cpp:3872: DB::StorageReplicatedMergeTree::processQueueEntry(std::shared_ptr) @ 0x0000000015efc18a 23. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001624c1b2 24. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000162f9c70 25. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x00000000162fa55a 26. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc6653 27. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000000fccc4c3 28. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc3d92 29. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fcca080 30. ? @ 0x00007fbc6213eac3 31. ? @ 0x00007fbc621d0850 (version 25.3.6.10636.altinitytest (altinity build)) 2025.07.28 11:56:25.884673 [ 17270 ] {7cac126b-f9ad-472c-a637-5a7a5866f392} executeQuery: Code: 219. DB::Exception: New table appeared in database being dropped or detached. Try again. (DATABASE_NOT_EMPTY) (version 25.3.6.10636.altinitytest (altinity build)) (from [::1]:40046) (comment: 03098_prefer_column_to_alias_subquery.sql) (in query: DROP DATABASE IF EXISTS test_pzlbyip0 SYNC ), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000000a074fcb 4. /build/src/Interpreters/DatabaseCatalog.cpp:608: DB::DatabaseCatalog::detachDatabase(std::shared_ptr, String const&, bool, bool) @ 0x00000000144f41b9 5. /build/src/Interpreters/InterpreterDropQuery.cpp:482: DB::InterpreterDropQuery::executeToDatabaseImpl(DB::ASTDropQuery const&, std::shared_ptr&, std::vector, DB::UUIDTag>, std::allocator, DB::UUIDTag>>>&) @ 0x00000000149179be 6. /build/src/Interpreters/InterpreterDropQuery.cpp:363: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x0000000014913988 7. /build/src/Interpreters/InterpreterDropQuery.cpp:99: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000014913142 8. /build/src/Interpreters/InterpreterDropQuery.cpp:72: DB::InterpreterDropQuery::execute() @ 0x0000000014912b65 9. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88dc9 10. /build/src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x0000000014c8ca7b 11. /build/src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000001686da12 12. /build/src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x0000000016870807 13. /build/src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x0000000016907e99 14. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 15. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 16. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 17. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 18. ? @ 0x00007fbc6213eac3 19. ? @ 0x00007fbc621d0850 2025.07.28 11:56:25.886559 [ 17270 ] {7cac126b-f9ad-472c-a637-5a7a5866f392} 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. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000000a074fcb 4. /build/src/Interpreters/DatabaseCatalog.cpp:608: DB::DatabaseCatalog::detachDatabase(std::shared_ptr, String const&, bool, bool) @ 0x00000000144f41b9 5. /build/src/Interpreters/InterpreterDropQuery.cpp:482: DB::InterpreterDropQuery::executeToDatabaseImpl(DB::ASTDropQuery const&, std::shared_ptr&, std::vector, DB::UUIDTag>, std::allocator, DB::UUIDTag>>>&) @ 0x00000000149179be 6. /build/src/Interpreters/InterpreterDropQuery.cpp:363: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x0000000014913988 7. /build/src/Interpreters/InterpreterDropQuery.cpp:99: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000014913142 8. /build/src/Interpreters/InterpreterDropQuery.cpp:72: DB::InterpreterDropQuery::execute() @ 0x0000000014912b65 9. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88dc9 10. /build/src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x0000000014c8ca7b 11. /build/src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000001686da12 12. /build/src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x0000000016870807 13. /build/src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x0000000016907e99 14. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 15. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 16. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 17. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 18. ? @ 0x00007fbc6213eac3 19. ? @ 0x00007fbc621d0850 (version 25.3.6.10636.altinitytest (altinity build)) 2025.07.28 11:56:26.165197 [ 3962 ] {} test_13.rmt2 (7f9b740d-015c-470e-8cc6-8ba33be0dc63): auto DB::StorageReplicatedMergeTree::processQueueEntry(ReplicatedMergeTreeQueue::SelectedEntryPtr)::(anonymous class)::operator()(LogEntryPtr &) const: Code: 86. DB::HTTPException: Received error from remote server http://146b4357c08d:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Ftest%2F01165%2Ftest_13%2Frmt%2Freplicas%2F1&part=20250728_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.6.10636.altinitytest (altinity build)) '. (RECEIVED_ERROR_FROM_REMOTE_IO_SERVER), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.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 const&, int&&, String const&, unsigned long&&, String const&) @ 0x000000000feda8d9 4. /build/src/IO/HTTPCommon.cpp:104: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x000000000feda6e2 5. /build/src/IO/HTTPCommon.cpp:93: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x000000000feda537 6. /build/src/IO/ReadWriteBufferFromHTTP.cpp:277: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x000000001184a4c4 7. /build/src/IO/ReadWriteBufferFromHTTP.cpp:285: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x000000001184a615 8. /build/src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x000000001184ae59 9. /build/src/IO/ReadWriteBufferFromHTTP.cpp:472: void std::__function::__policy_invoker::__call_impl[abi:se190107]>(std::__function::__policy_storage const*) @ 0x000000001184cedd 10. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001184858b 11. /build/src/IO/ReadWriteBufferFromHTTP.cpp:465: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x000000001184bf0b 12. /build/src/IO/ReadBuffer.h:60: DB::ReadBuffer::next() @ 0x000000000a148c7b 13. /build/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) @ 0x0000000011849fb2 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]>&)>&, 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&) @ 0x0000000011841980 15. /build/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) @ 0x000000001621208e 16. /build/src/Storages/StorageReplicatedMergeTree.cpp:5228: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl[abi:se190107] const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000015f9a5fe 17. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000015ed8bfd 18. /build/src/Storages/StorageReplicatedMergeTree.cpp:2514: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x0000000015ec9aab 19. /build/src/Storages/StorageReplicatedMergeTree.cpp:2349: DB::StorageReplicatedMergeTree::executeLogEntry(DB::ReplicatedMergeTreeLogEntry&) @ 0x0000000015eba91b 20. /build/src/Storages/StorageReplicatedMergeTree.cpp:3876: bool std::__function::__policy_invoker&)>::__call_impl[abi:se190107])::$_1, bool (std::shared_ptr&)>>(std::__function::__policy_storage const*, std::shared_ptr&) @ 0x0000000015f9837e 21. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000165d6fc3 22. /build/src/Storages/StorageReplicatedMergeTree.cpp:3872: DB::StorageReplicatedMergeTree::processQueueEntry(std::shared_ptr) @ 0x0000000015efc18a 23. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001624c1b2 24. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000162f9c70 25. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x00000000162fa55a 26. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc6653 27. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000000fccc4c3 28. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc3d92 29. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fcca080 30. ? @ 0x00007fbc6213eac3 31. ? @ 0x00007fbc621d0850 (version 25.3.6.10636.altinitytest (altinity build)) 2025.07.28 11:56:26.188115 [ 3285 ] {c9d78dac-41c2-4592-9e6d-12aedf23c9f7} executeQuery: Code: 219. DB::Exception: New table appeared in database being dropped or detached. Try again. (DATABASE_NOT_EMPTY) (version 25.3.6.10636.altinitytest (altinity build)) (from [::1]:40082) (comment: 02048_parallel_reading_from_infile.sh) (in query: DROP DATABASE IF EXISTS test_lpnndmh6 SYNC ), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000000a074fcb 4. /build/src/Interpreters/DatabaseCatalog.cpp:608: DB::DatabaseCatalog::detachDatabase(std::shared_ptr, String const&, bool, bool) @ 0x00000000144f41b9 5. /build/src/Interpreters/InterpreterDropQuery.cpp:482: DB::InterpreterDropQuery::executeToDatabaseImpl(DB::ASTDropQuery const&, std::shared_ptr&, std::vector, DB::UUIDTag>, std::allocator, DB::UUIDTag>>>&) @ 0x00000000149179be 6. /build/src/Interpreters/InterpreterDropQuery.cpp:363: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x0000000014913988 7. /build/src/Interpreters/InterpreterDropQuery.cpp:99: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000014913142 8. /build/src/Interpreters/InterpreterDropQuery.cpp:72: DB::InterpreterDropQuery::execute() @ 0x0000000014912b65 9. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88dc9 10. /build/src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x0000000014c8ca7b 11. /build/src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000001686da12 12. /build/src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x0000000016870807 13. /build/src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x0000000016907e99 14. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 15. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 16. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 17. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 18. ? @ 0x00007fbc6213eac3 19. ? @ 0x00007fbc621d0850 2025.07.28 11:56:26.190308 [ 3285 ] {c9d78dac-41c2-4592-9e6d-12aedf23c9f7} 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. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000000a074fcb 4. /build/src/Interpreters/DatabaseCatalog.cpp:608: DB::DatabaseCatalog::detachDatabase(std::shared_ptr, String const&, bool, bool) @ 0x00000000144f41b9 5. /build/src/Interpreters/InterpreterDropQuery.cpp:482: DB::InterpreterDropQuery::executeToDatabaseImpl(DB::ASTDropQuery const&, std::shared_ptr&, std::vector, DB::UUIDTag>, std::allocator, DB::UUIDTag>>>&) @ 0x00000000149179be 6. /build/src/Interpreters/InterpreterDropQuery.cpp:363: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x0000000014913988 7. /build/src/Interpreters/InterpreterDropQuery.cpp:99: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000014913142 8. /build/src/Interpreters/InterpreterDropQuery.cpp:72: DB::InterpreterDropQuery::execute() @ 0x0000000014912b65 9. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88dc9 10. /build/src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x0000000014c8ca7b 11. /build/src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000001686da12 12. /build/src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x0000000016870807 13. /build/src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x0000000016907e99 14. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 15. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 16. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 17. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 18. ? @ 0x00007fbc6213eac3 19. ? @ 0x00007fbc621d0850 (version 25.3.6.10636.altinitytest (altinity build)) 2025.07.28 11:56:26.775695 [ 3963 ] {} test_13.rmt2 (7f9b740d-015c-470e-8cc6-8ba33be0dc63): auto DB::StorageReplicatedMergeTree::processQueueEntry(ReplicatedMergeTreeQueue::SelectedEntryPtr)::(anonymous class)::operator()(LogEntryPtr &) const: Code: 86. DB::HTTPException: Received error from remote server http://146b4357c08d:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Ftest%2F01165%2Ftest_13%2Frmt%2Freplicas%2F1&part=20250728_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.6.10636.altinitytest (altinity build)) '. (RECEIVED_ERROR_FROM_REMOTE_IO_SERVER), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.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 const&, int&&, String const&, unsigned long&&, String const&) @ 0x000000000feda8d9 4. /build/src/IO/HTTPCommon.cpp:104: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x000000000feda6e2 5. /build/src/IO/HTTPCommon.cpp:93: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x000000000feda537 6. /build/src/IO/ReadWriteBufferFromHTTP.cpp:277: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x000000001184a4c4 7. /build/src/IO/ReadWriteBufferFromHTTP.cpp:285: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x000000001184a615 8. /build/src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x000000001184ae59 9. /build/src/IO/ReadWriteBufferFromHTTP.cpp:472: void std::__function::__policy_invoker::__call_impl[abi:se190107]>(std::__function::__policy_storage const*) @ 0x000000001184cedd 10. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001184858b 11. /build/src/IO/ReadWriteBufferFromHTTP.cpp:465: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x000000001184bf0b 12. /build/src/IO/ReadBuffer.h:60: DB::ReadBuffer::next() @ 0x000000000a148c7b 13. /build/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) @ 0x0000000011849fb2 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]>&)>&, 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&) @ 0x0000000011841980 15. /build/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) @ 0x000000001621208e 16. /build/src/Storages/StorageReplicatedMergeTree.cpp:5228: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl[abi:se190107] const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000015f9a5fe 17. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000015ed8bfd 18. /build/src/Storages/StorageReplicatedMergeTree.cpp:2514: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x0000000015ec9aab 19. /build/src/Storages/StorageReplicatedMergeTree.cpp:2349: DB::StorageReplicatedMergeTree::executeLogEntry(DB::ReplicatedMergeTreeLogEntry&) @ 0x0000000015eba91b 20. /build/src/Storages/StorageReplicatedMergeTree.cpp:3876: bool std::__function::__policy_invoker&)>::__call_impl[abi:se190107])::$_1, bool (std::shared_ptr&)>>(std::__function::__policy_storage const*, std::shared_ptr&) @ 0x0000000015f9837e 21. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000165d6fc3 22. /build/src/Storages/StorageReplicatedMergeTree.cpp:3872: DB::StorageReplicatedMergeTree::processQueueEntry(std::shared_ptr) @ 0x0000000015efc18a 23. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001624c1b2 24. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000162f9c70 25. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x00000000162fa55a 26. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc6653 27. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000000fccc4c3 28. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc3d92 29. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fcca080 30. ? @ 0x00007fbc6213eac3 31. ? @ 0x00007fbc621d0850 (version 25.3.6.10636.altinitytest (altinity build)) 2025.07.28 11:56:26.933023 [ 3969 ] {} test_13.rmt2 (7f9b740d-015c-470e-8cc6-8ba33be0dc63): auto DB::StorageReplicatedMergeTree::processQueueEntry(ReplicatedMergeTreeQueue::SelectedEntryPtr)::(anonymous class)::operator()(LogEntryPtr &) const: Code: 86. DB::HTTPException: Received error from remote server http://146b4357c08d:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Ftest%2F01165%2Ftest_13%2Frmt%2Freplicas%2F1&part=20250728_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.6.10636.altinitytest (altinity build)) '. (RECEIVED_ERROR_FROM_REMOTE_IO_SERVER), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.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 const&, int&&, String const&, unsigned long&&, String const&) @ 0x000000000feda8d9 4. /build/src/IO/HTTPCommon.cpp:104: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x000000000feda6e2 5. /build/src/IO/HTTPCommon.cpp:93: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x000000000feda537 6. /build/src/IO/ReadWriteBufferFromHTTP.cpp:277: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x000000001184a4c4 7. /build/src/IO/ReadWriteBufferFromHTTP.cpp:285: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x000000001184a615 8. /build/src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x000000001184ae59 9. /build/src/IO/ReadWriteBufferFromHTTP.cpp:472: void std::__function::__policy_invoker::__call_impl[abi:se190107]>(std::__function::__policy_storage const*) @ 0x000000001184cedd 10. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001184858b 11. /build/src/IO/ReadWriteBufferFromHTTP.cpp:465: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x000000001184bf0b 12. /build/src/IO/ReadBuffer.h:60: DB::ReadBuffer::next() @ 0x000000000a148c7b 13. /build/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) @ 0x0000000011849fb2 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]>&)>&, 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&) @ 0x0000000011841980 15. /build/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) @ 0x000000001621208e 16. /build/src/Storages/StorageReplicatedMergeTree.cpp:5228: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl[abi:se190107] const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000015f9a5fe 17. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000015ed8bfd 18. /build/src/Storages/StorageReplicatedMergeTree.cpp:2514: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x0000000015ec9aab 19. /build/src/Storages/StorageReplicatedMergeTree.cpp:2349: DB::StorageReplicatedMergeTree::executeLogEntry(DB::ReplicatedMergeTreeLogEntry&) @ 0x0000000015eba91b 20. /build/src/Storages/StorageReplicatedMergeTree.cpp:3876: bool std::__function::__policy_invoker&)>::__call_impl[abi:se190107])::$_1, bool (std::shared_ptr&)>>(std::__function::__policy_storage const*, std::shared_ptr&) @ 0x0000000015f9837e 21. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000165d6fc3 22. /build/src/Storages/StorageReplicatedMergeTree.cpp:3872: DB::StorageReplicatedMergeTree::processQueueEntry(std::shared_ptr) @ 0x0000000015efc18a 23. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001624c1b2 24. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000162f9c70 25. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x00000000162fa55a 26. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc6653 27. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000000fccc4c3 28. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc3d92 29. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fcca080 30. ? @ 0x00007fbc6213eac3 31. ? @ 0x00007fbc621d0850 (version 25.3.6.10636.altinitytest (altinity build)) 2025.07.28 11:56:27.774710 [ 3967 ] {} test_13.rmt2 (7f9b740d-015c-470e-8cc6-8ba33be0dc63): auto DB::StorageReplicatedMergeTree::processQueueEntry(ReplicatedMergeTreeQueue::SelectedEntryPtr)::(anonymous class)::operator()(LogEntryPtr &) const: Code: 86. DB::HTTPException: Received error from remote server http://146b4357c08d:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Ftest%2F01165%2Ftest_13%2Frmt%2Freplicas%2F1&part=20250728_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.6.10636.altinitytest (altinity build)) '. (RECEIVED_ERROR_FROM_REMOTE_IO_SERVER), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.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 const&, int&&, String const&, unsigned long&&, String const&) @ 0x000000000feda8d9 4. /build/src/IO/HTTPCommon.cpp:104: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x000000000feda6e2 5. /build/src/IO/HTTPCommon.cpp:93: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x000000000feda537 6. /build/src/IO/ReadWriteBufferFromHTTP.cpp:277: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x000000001184a4c4 7. /build/src/IO/ReadWriteBufferFromHTTP.cpp:285: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x000000001184a615 8. /build/src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x000000001184ae59 9. /build/src/IO/ReadWriteBufferFromHTTP.cpp:472: void std::__function::__policy_invoker::__call_impl[abi:se190107]>(std::__function::__policy_storage const*) @ 0x000000001184cedd 10. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001184858b 11. /build/src/IO/ReadWriteBufferFromHTTP.cpp:465: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x000000001184bf0b 12. /build/src/IO/ReadBuffer.h:60: DB::ReadBuffer::next() @ 0x000000000a148c7b 13. /build/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) @ 0x0000000011849fb2 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]>&)>&, 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&) @ 0x0000000011841980 15. /build/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) @ 0x000000001621208e 16. /build/src/Storages/StorageReplicatedMergeTree.cpp:5228: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl[abi:se190107] const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000015f9a5fe 17. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000015ed8bfd 18. /build/src/Storages/StorageReplicatedMergeTree.cpp:2514: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x0000000015ec9aab 19. /build/src/Storages/StorageReplicatedMergeTree.cpp:2349: DB::StorageReplicatedMergeTree::executeLogEntry(DB::ReplicatedMergeTreeLogEntry&) @ 0x0000000015eba91b 20. /build/src/Storages/StorageReplicatedMergeTree.cpp:3876: bool std::__function::__policy_invoker&)>::__call_impl[abi:se190107])::$_1, bool (std::shared_ptr&)>>(std::__function::__policy_storage const*, std::shared_ptr&) @ 0x0000000015f9837e 21. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000165d6fc3 22. /build/src/Storages/StorageReplicatedMergeTree.cpp:3872: DB::StorageReplicatedMergeTree::processQueueEntry(std::shared_ptr) @ 0x0000000015efc18a 23. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001624c1b2 24. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000162f9c70 25. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x00000000162fa55a 26. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc6653 27. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000000fccc4c3 28. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc3d92 29. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fcca080 30. ? @ 0x00007fbc6213eac3 31. ? @ 0x00007fbc621d0850 (version 25.3.6.10636.altinitytest (altinity build)) 2025.07.28 11:56:28.114891 [ 3968 ] {} test_13.rmt2 (7f9b740d-015c-470e-8cc6-8ba33be0dc63): auto DB::StorageReplicatedMergeTree::processQueueEntry(ReplicatedMergeTreeQueue::SelectedEntryPtr)::(anonymous class)::operator()(LogEntryPtr &) const: Code: 86. DB::HTTPException: Received error from remote server http://146b4357c08d:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Ftest%2F01165%2Ftest_13%2Frmt%2Freplicas%2F1&part=20250728_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.6.10636.altinitytest (altinity build)) '. (RECEIVED_ERROR_FROM_REMOTE_IO_SERVER), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.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 const&, int&&, String const&, unsigned long&&, String const&) @ 0x000000000feda8d9 4. /build/src/IO/HTTPCommon.cpp:104: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x000000000feda6e2 5. /build/src/IO/HTTPCommon.cpp:93: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x000000000feda537 6. /build/src/IO/ReadWriteBufferFromHTTP.cpp:277: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x000000001184a4c4 7. /build/src/IO/ReadWriteBufferFromHTTP.cpp:285: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x000000001184a615 8. /build/src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x000000001184ae59 9. /build/src/IO/ReadWriteBufferFromHTTP.cpp:472: void std::__function::__policy_invoker::__call_impl[abi:se190107]>(std::__function::__policy_storage const*) @ 0x000000001184cedd 10. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001184858b 11. /build/src/IO/ReadWriteBufferFromHTTP.cpp:465: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x000000001184bf0b 12. /build/src/IO/ReadBuffer.h:60: DB::ReadBuffer::next() @ 0x000000000a148c7b 13. /build/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) @ 0x0000000011849fb2 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]>&)>&, 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&) @ 0x0000000011841980 15. /build/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) @ 0x000000001621208e 16. /build/src/Storages/StorageReplicatedMergeTree.cpp:5228: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl[abi:se190107] const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000015f9a5fe 17. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000015ed8bfd 18. /build/src/Storages/StorageReplicatedMergeTree.cpp:2514: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x0000000015ec9aab 19. /build/src/Storages/StorageReplicatedMergeTree.cpp:2349: DB::StorageReplicatedMergeTree::executeLogEntry(DB::ReplicatedMergeTreeLogEntry&) @ 0x0000000015eba91b 20. /build/src/Storages/StorageReplicatedMergeTree.cpp:3876: bool std::__function::__policy_invoker&)>::__call_impl[abi:se190107])::$_1, bool (std::shared_ptr&)>>(std::__function::__policy_storage const*, std::shared_ptr&) @ 0x0000000015f9837e 21. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000165d6fc3 22. /build/src/Storages/StorageReplicatedMergeTree.cpp:3872: DB::StorageReplicatedMergeTree::processQueueEntry(std::shared_ptr) @ 0x0000000015efc18a 23. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001624c1b2 24. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000162f9c70 25. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x00000000162fa55a 26. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc6653 27. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000000fccc4c3 28. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc3d92 29. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fcca080 30. ? @ 0x00007fbc6213eac3 31. ? @ 0x00007fbc621d0850 (version 25.3.6.10636.altinitytest (altinity build)) 2025.07.28 11:56:28.549910 [ 3960 ] {} test_13.rmt2 (7f9b740d-015c-470e-8cc6-8ba33be0dc63): auto DB::StorageReplicatedMergeTree::processQueueEntry(ReplicatedMergeTreeQueue::SelectedEntryPtr)::(anonymous class)::operator()(LogEntryPtr &) const: Code: 86. DB::HTTPException: Received error from remote server http://146b4357c08d:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Ftest%2F01165%2Ftest_13%2Frmt%2Freplicas%2F1&part=20250728_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.6.10636.altinitytest (altinity build)) '. (RECEIVED_ERROR_FROM_REMOTE_IO_SERVER), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.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 const&, int&&, String const&, unsigned long&&, String const&) @ 0x000000000feda8d9 4. /build/src/IO/HTTPCommon.cpp:104: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x000000000feda6e2 5. /build/src/IO/HTTPCommon.cpp:93: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x000000000feda537 6. /build/src/IO/ReadWriteBufferFromHTTP.cpp:277: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x000000001184a4c4 7. /build/src/IO/ReadWriteBufferFromHTTP.cpp:285: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x000000001184a615 8. /build/src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x000000001184ae59 9. /build/src/IO/ReadWriteBufferFromHTTP.cpp:472: void std::__function::__policy_invoker::__call_impl[abi:se190107]>(std::__function::__policy_storage const*) @ 0x000000001184cedd 10. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001184858b 11. /build/src/IO/ReadWriteBufferFromHTTP.cpp:465: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x000000001184bf0b 12. /build/src/IO/ReadBuffer.h:60: DB::ReadBuffer::next() @ 0x000000000a148c7b 13. /build/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) @ 0x0000000011849fb2 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]>&)>&, 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&) @ 0x0000000011841980 15. /build/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) @ 0x000000001621208e 16. /build/src/Storages/StorageReplicatedMergeTree.cpp:5228: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl[abi:se190107] const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000015f9a5fe 17. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000015ed8bfd 18. /build/src/Storages/StorageReplicatedMergeTree.cpp:2514: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x0000000015ec9aab 19. /build/src/Storages/StorageReplicatedMergeTree.cpp:2349: DB::StorageReplicatedMergeTree::executeLogEntry(DB::ReplicatedMergeTreeLogEntry&) @ 0x0000000015eba91b 20. /build/src/Storages/StorageReplicatedMergeTree.cpp:3876: bool std::__function::__policy_invoker&)>::__call_impl[abi:se190107])::$_1, bool (std::shared_ptr&)>>(std::__function::__policy_storage const*, std::shared_ptr&) @ 0x0000000015f9837e 21. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000165d6fc3 22. /build/src/Storages/StorageReplicatedMergeTree.cpp:3872: DB::StorageReplicatedMergeTree::processQueueEntry(std::shared_ptr) @ 0x0000000015efc18a 23. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001624c1b2 24. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000162f9c70 25. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x00000000162fa55a 26. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc6653 27. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000000fccc4c3 28. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc3d92 29. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fcca080 30. ? @ 0x00007fbc6213eac3 31. ? @ 0x00007fbc621d0850 (version 25.3.6.10636.altinitytest (altinity build)) 2025.07.28 11:56:28.967493 [ 3961 ] {} test_13.rmt2 (7f9b740d-015c-470e-8cc6-8ba33be0dc63): auto DB::StorageReplicatedMergeTree::processQueueEntry(ReplicatedMergeTreeQueue::SelectedEntryPtr)::(anonymous class)::operator()(LogEntryPtr &) const: Code: 86. DB::HTTPException: Received error from remote server http://146b4357c08d:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Ftest%2F01165%2Ftest_13%2Frmt%2Freplicas%2F1&part=20250728_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.6.10636.altinitytest (altinity build)) '. (RECEIVED_ERROR_FROM_REMOTE_IO_SERVER), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.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 const&, int&&, String const&, unsigned long&&, String const&) @ 0x000000000feda8d9 4. /build/src/IO/HTTPCommon.cpp:104: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x000000000feda6e2 5. /build/src/IO/HTTPCommon.cpp:93: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x000000000feda537 6. /build/src/IO/ReadWriteBufferFromHTTP.cpp:277: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x000000001184a4c4 7. /build/src/IO/ReadWriteBufferFromHTTP.cpp:285: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x000000001184a615 8. /build/src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x000000001184ae59 9. /build/src/IO/ReadWriteBufferFromHTTP.cpp:472: void std::__function::__policy_invoker::__call_impl[abi:se190107]>(std::__function::__policy_storage const*) @ 0x000000001184cedd 10. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001184858b 11. /build/src/IO/ReadWriteBufferFromHTTP.cpp:465: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x000000001184bf0b 12. /build/src/IO/ReadBuffer.h:60: DB::ReadBuffer::next() @ 0x000000000a148c7b 13. /build/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) @ 0x0000000011849fb2 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]>&)>&, 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&) @ 0x0000000011841980 15. /build/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) @ 0x000000001621208e 16. /build/src/Storages/StorageReplicatedMergeTree.cpp:5228: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl[abi:se190107] const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000015f9a5fe 17. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000015ed8bfd 18. /build/src/Storages/StorageReplicatedMergeTree.cpp:2514: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x0000000015ec9aab 19. /build/src/Storages/StorageReplicatedMergeTree.cpp:2349: DB::StorageReplicatedMergeTree::executeLogEntry(DB::ReplicatedMergeTreeLogEntry&) @ 0x0000000015eba91b 20. /build/src/Storages/StorageReplicatedMergeTree.cpp:3876: bool std::__function::__policy_invoker&)>::__call_impl[abi:se190107])::$_1, bool (std::shared_ptr&)>>(std::__function::__policy_storage const*, std::shared_ptr&) @ 0x0000000015f9837e 21. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000165d6fc3 22. /build/src/Storages/StorageReplicatedMergeTree.cpp:3872: DB::StorageReplicatedMergeTree::processQueueEntry(std::shared_ptr) @ 0x0000000015efc18a 23. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001624c1b2 24. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000162f9c70 25. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x00000000162fa55a 26. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc6653 27. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000000fccc4c3 28. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc3d92 29. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fcca080 30. ? @ 0x00007fbc6213eac3 31. ? @ 0x00007fbc621d0850 (version 25.3.6.10636.altinitytest (altinity build)) 2025.07.28 11:56:29.388584 [ 3972 ] {} test_13.rmt2 (7f9b740d-015c-470e-8cc6-8ba33be0dc63): auto DB::StorageReplicatedMergeTree::processQueueEntry(ReplicatedMergeTreeQueue::SelectedEntryPtr)::(anonymous class)::operator()(LogEntryPtr &) const: Code: 86. DB::HTTPException: Received error from remote server http://146b4357c08d:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Ftest%2F01165%2Ftest_13%2Frmt%2Freplicas%2F1&part=20250728_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.6.10636.altinitytest (altinity build)) '. (RECEIVED_ERROR_FROM_REMOTE_IO_SERVER), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.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 const&, int&&, String const&, unsigned long&&, String const&) @ 0x000000000feda8d9 4. /build/src/IO/HTTPCommon.cpp:104: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x000000000feda6e2 5. /build/src/IO/HTTPCommon.cpp:93: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x000000000feda537 6. /build/src/IO/ReadWriteBufferFromHTTP.cpp:277: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x000000001184a4c4 7. /build/src/IO/ReadWriteBufferFromHTTP.cpp:285: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x000000001184a615 8. /build/src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x000000001184ae59 9. /build/src/IO/ReadWriteBufferFromHTTP.cpp:472: void std::__function::__policy_invoker::__call_impl[abi:se190107]>(std::__function::__policy_storage const*) @ 0x000000001184cedd 10. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001184858b 11. /build/src/IO/ReadWriteBufferFromHTTP.cpp:465: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x000000001184bf0b 12. /build/src/IO/ReadBuffer.h:60: DB::ReadBuffer::next() @ 0x000000000a148c7b 13. /build/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) @ 0x0000000011849fb2 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]>&)>&, 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&) @ 0x0000000011841980 15. /build/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) @ 0x000000001621208e 16. /build/src/Storages/StorageReplicatedMergeTree.cpp:5228: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl[abi:se190107] const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000015f9a5fe 17. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000015ed8bfd 18. /build/src/Storages/StorageReplicatedMergeTree.cpp:2514: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x0000000015ec9aab 19. /build/src/Storages/StorageReplicatedMergeTree.cpp:2349: DB::StorageReplicatedMergeTree::executeLogEntry(DB::ReplicatedMergeTreeLogEntry&) @ 0x0000000015eba91b 20. /build/src/Storages/StorageReplicatedMergeTree.cpp:3876: bool std::__function::__policy_invoker&)>::__call_impl[abi:se190107])::$_1, bool (std::shared_ptr&)>>(std::__function::__policy_storage const*, std::shared_ptr&) @ 0x0000000015f9837e 21. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000165d6fc3 22. /build/src/Storages/StorageReplicatedMergeTree.cpp:3872: DB::StorageReplicatedMergeTree::processQueueEntry(std::shared_ptr) @ 0x0000000015efc18a 23. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001624c1b2 24. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000162f9c70 25. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x00000000162fa55a 26. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc6653 27. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000000fccc4c3 28. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc3d92 29. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fcca080 30. ? @ 0x00007fbc6213eac3 31. ? @ 0x00007fbc621d0850 (version 25.3.6.10636.altinitytest (altinity build)) 2025.07.28 11:56:29.478800 [ 3285 ] {13ccd18b-ea62-4a99-bf6c-de3b573d66d4} executeQuery: Code: 10. DB::Exception: Not found column dt: in block __table1.pk Nullable(Nothing) Const(size = 0, Nullable(size = 1, Nothing(size = 1), UInt8(size = 1))). (NOT_FOUND_COLUMN_IN_BLOCK) (version 25.3.6.10636.altinitytest (altinity build)) (from [::1]:37326) (comment: 02479_analyzer_join_with_constants.sql) (query 14, line 27) (in query: SELECT b.dt FROM (SELECT NULL > NULL AS pk, 1 AS dt FROM numbers(5)) AS a ASOF LEFT JOIN (SELECT NULL AS pk, 1 AS dt) AS b ON (a.pk = b.pk) AND 1 != 1 AND (a.dt >= b.dt);), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000a9b78ab 4. /build/src/Interpreters/ActionsDAG.cpp:977: DB::ActionsDAG::evaluatePartialResult(std::unordered_map, std::equal_to, std::allocator>>&, std::vector> const&, unsigned long, bool) @ 0x0000000013fa407d 5. /build/src/Interpreters/ActionsDAG.cpp:892: DB::ActionsDAG::updateHeader(DB::Block const&) const @ 0x0000000013fa29a8 6. /build/src/Processors/Transforms/ExpressionTransform.cpp:10: DB::ExpressionTransform::transformHeader(DB::Block const&, DB::ActionsDAG const&) @ 0x0000000016c0afd2 7. /build/src/Processors/QueryPlan/ExpressionStep.cpp:38: DB::ExpressionStep::ExpressionStep(DB::Block const&, DB::ActionsDAG) @ 0x0000000016db8ad1 8. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107](DB::Block const&, DB::ActionsDAG&&) @ 0x00000000131ee01a 9. /build/src/Processors/QueryPlan/Optimizations/Utils.cpp:31: DB::QueryPlanOptimizations::makeExpressionNodeOnTopOf(DB::QueryPlan::Node*, DB::ActionsDAG, String const&, std::list>&) @ 0x0000000016eb89f5 10. /build/src/Processors/QueryPlan/Optimizations/optimizeJoin.cpp:273: DB::QueryPlanOptimizations::convertLogicalJoinToPhysical(DB::QueryPlan::Node&, std::list>&, DB::QueryPlanOptimizationSettings const&, std::optional) @ 0x0000000016eb5e6d 11. /build/src/Processors/QueryPlan/Optimizations/optimizeTree.cpp:158: DB::QueryPlanOptimizations::optimizeTreeSecondPass(DB::QueryPlanOptimizationSettings const&, DB::QueryPlan::Node&, std::list>&) @ 0x0000000016ead357 12. /build/src/Processors/QueryPlan/QueryPlan.cpp:487: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x0000000016e0055c 13. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:275: DB::InterpreterSelectQueryAnalyzer::buildQueryPipeline() @ 0x0000000014974614 14. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:242: DB::InterpreterSelectQueryAnalyzer::execute() @ 0x000000001497439e 15. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88dc9 16. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 17. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 18. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 19. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 20. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 21. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 22. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 23. ? @ 0x00007fbc6213eac3 24. ? @ 0x00007fbc621d0850 2025.07.28 11:56:29.482165 [ 3285 ] {} TCPHandler: Code: 10. DB::Exception: Not found column dt: in block __table1.pk Nullable(Nothing) Const(size = 0, Nullable(size = 1, Nothing(size = 1), UInt8(size = 1))). (NOT_FOUND_COLUMN_IN_BLOCK), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000a9b78ab 4. /build/src/Interpreters/ActionsDAG.cpp:977: DB::ActionsDAG::evaluatePartialResult(std::unordered_map, std::equal_to, std::allocator>>&, std::vector> const&, unsigned long, bool) @ 0x0000000013fa407d 5. /build/src/Interpreters/ActionsDAG.cpp:892: DB::ActionsDAG::updateHeader(DB::Block const&) const @ 0x0000000013fa29a8 6. /build/src/Processors/Transforms/ExpressionTransform.cpp:10: DB::ExpressionTransform::transformHeader(DB::Block const&, DB::ActionsDAG const&) @ 0x0000000016c0afd2 7. /build/src/Processors/QueryPlan/ExpressionStep.cpp:38: DB::ExpressionStep::ExpressionStep(DB::Block const&, DB::ActionsDAG) @ 0x0000000016db8ad1 8. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107](DB::Block const&, DB::ActionsDAG&&) @ 0x00000000131ee01a 9. /build/src/Processors/QueryPlan/Optimizations/Utils.cpp:31: DB::QueryPlanOptimizations::makeExpressionNodeOnTopOf(DB::QueryPlan::Node*, DB::ActionsDAG, String const&, std::list>&) @ 0x0000000016eb89f5 10. /build/src/Processors/QueryPlan/Optimizations/optimizeJoin.cpp:273: DB::QueryPlanOptimizations::convertLogicalJoinToPhysical(DB::QueryPlan::Node&, std::list>&, DB::QueryPlanOptimizationSettings const&, std::optional) @ 0x0000000016eb5e6d 11. /build/src/Processors/QueryPlan/Optimizations/optimizeTree.cpp:158: DB::QueryPlanOptimizations::optimizeTreeSecondPass(DB::QueryPlanOptimizationSettings const&, DB::QueryPlan::Node&, std::list>&) @ 0x0000000016ead357 12. /build/src/Processors/QueryPlan/QueryPlan.cpp:487: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x0000000016e0055c 13. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:275: DB::InterpreterSelectQueryAnalyzer::buildQueryPipeline() @ 0x0000000014974614 14. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:242: DB::InterpreterSelectQueryAnalyzer::execute() @ 0x000000001497439e 15. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88dc9 16. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 17. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 18. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 19. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 20. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 21. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 22. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 23. ? @ 0x00007fbc6213eac3 24. ? @ 0x00007fbc621d0850 2025.07.28 11:56:29.689056 [ 3964 ] {} test_13.rmt2 (7f9b740d-015c-470e-8cc6-8ba33be0dc63): auto DB::StorageReplicatedMergeTree::processQueueEntry(ReplicatedMergeTreeQueue::SelectedEntryPtr)::(anonymous class)::operator()(LogEntryPtr &) const: Code: 86. DB::HTTPException: Received error from remote server http://146b4357c08d:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Ftest%2F01165%2Ftest_13%2Frmt%2Freplicas%2F1&part=20250728_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.6.10636.altinitytest (altinity build)) '. (RECEIVED_ERROR_FROM_REMOTE_IO_SERVER), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.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 const&, int&&, String const&, unsigned long&&, String const&) @ 0x000000000feda8d9 4. /build/src/IO/HTTPCommon.cpp:104: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x000000000feda6e2 5. /build/src/IO/HTTPCommon.cpp:93: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x000000000feda537 6. /build/src/IO/ReadWriteBufferFromHTTP.cpp:277: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x000000001184a4c4 7. /build/src/IO/ReadWriteBufferFromHTTP.cpp:285: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x000000001184a615 8. /build/src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x000000001184ae59 9. /build/src/IO/ReadWriteBufferFromHTTP.cpp:472: void std::__function::__policy_invoker::__call_impl[abi:se190107]>(std::__function::__policy_storage const*) @ 0x000000001184cedd 10. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001184858b 11. /build/src/IO/ReadWriteBufferFromHTTP.cpp:465: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x000000001184bf0b 12. /build/src/IO/ReadBuffer.h:60: DB::ReadBuffer::next() @ 0x000000000a148c7b 13. /build/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) @ 0x0000000011849fb2 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]>&)>&, 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&) @ 0x0000000011841980 15. /build/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) @ 0x000000001621208e 16. /build/src/Storages/StorageReplicatedMergeTree.cpp:5228: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl[abi:se190107] const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000015f9a5fe 17. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000015ed8bfd 18. /build/src/Storages/StorageReplicatedMergeTree.cpp:2514: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x0000000015ec9aab 19. /build/src/Storages/StorageReplicatedMergeTree.cpp:2349: DB::StorageReplicatedMergeTree::executeLogEntry(DB::ReplicatedMergeTreeLogEntry&) @ 0x0000000015eba91b 20. /build/src/Storages/StorageReplicatedMergeTree.cpp:3876: bool std::__function::__policy_invoker&)>::__call_impl[abi:se190107])::$_1, bool (std::shared_ptr&)>>(std::__function::__policy_storage const*, std::shared_ptr&) @ 0x0000000015f9837e 21. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000165d6fc3 22. /build/src/Storages/StorageReplicatedMergeTree.cpp:3872: DB::StorageReplicatedMergeTree::processQueueEntry(std::shared_ptr) @ 0x0000000015efc18a 23. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001624c1b2 24. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000162f9c70 25. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x00000000162fa55a 26. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc6653 27. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000000fccc4c3 28. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc3d92 29. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fcca080 30. ? @ 0x00007fbc6213eac3 31. ? @ 0x00007fbc621d0850 (version 25.3.6.10636.altinitytest (altinity build)) 2025.07.28 11:56:29.876802 [ 11826 ] {a415aaed-e532-4a3b-b062-6cb95ee7ef8c} executeQuery: Code: 69. DB::Exception: Number is too big to place in Decimal(8, 8). (ARGUMENT_OUT_OF_BOUND) (version 25.3.6.10636.altinitytest (altinity build)) (from [::1]:37450) (comment: 01178_int_field_to_decimal.sql) (query 1, line 1) (in query: select d from values('d Decimal(8, 8)', 0, 1) where d not in (-1, 0);), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x000000000a06b56b 4. /build/src/Interpreters/convertFieldToType.cpp:93: DB::Field DB::(anonymous namespace)::convertDecimalType>>(DB::Field const&, DB::DataTypeDecimal> const&) @ 0x0000000014c5e923 5. /build/src/Interpreters/convertFieldToType.cpp:253: DB::(anonymous namespace)::convertFieldToTypeImpl(DB::Field const&, DB::IDataType const&, DB::IDataType const*, DB::FormatSettings const&) @ 0x0000000014c588b4 6. /build/src/Interpreters/convertFieldToType.cpp:633: DB::convertFieldToType(DB::Field const&, DB::IDataType const&, DB::IDataType const*, DB::FormatSettings const&) @ 0x0000000014c57687 7. /build/src/Interpreters/convertFieldToType.cpp:643: DB::convertFieldToTypeOrThrow(DB::Field const&, DB::IDataType const&, DB::IDataType const*, DB::FormatSettings const&) @ 0x0000000014c5a598 8. /build/src/TableFunctions/TableFunctionValues.cpp:67: DB::(anonymous namespace)::TableFunctionValues::executeImpl(std::shared_ptr const&, std::shared_ptr, String const&, DB::ColumnsDescription, bool) const @ 0x000000001182e037 9. /build/src/TableFunctions/ITableFunction.cpp:36: DB::ITableFunction::execute(std::shared_ptr const&, std::shared_ptr, String const&, DB::ColumnsDescription, bool, bool) const @ 0x00000000131e9fc3 10. /build/src/Interpreters/Context.cpp:2501: DB::Context::executeTableFunction(std::shared_ptr const&, std::shared_ptr const&) @ 0x00000000144345b2 11. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:4975: DB::QueryAnalyzer::resolveTableFunction(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&, bool) @ 0x000000001401e9f9 12. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5342: DB::QueryAnalyzer::resolveQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&) @ 0x00000000140452bf 13. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5597: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000140136f0 14. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000140127f9 15. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000014011fce 16. /build/src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000001406ce8a 17. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000014973b42 18. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000001497268d 19. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000014974d24 20. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001492924b 21. /build/src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88641 22. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 23. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 24. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 25. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 26. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 27. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 28. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 29. ? @ 0x00007fbc6213eac3 30. ? @ 0x00007fbc621d0850 2025.07.28 11:56:29.880277 [ 11826 ] {} TCPHandler: Code: 69. DB::Exception: Number is too big to place in Decimal(8, 8). (ARGUMENT_OUT_OF_BOUND), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x000000000a06b56b 4. /build/src/Interpreters/convertFieldToType.cpp:93: DB::Field DB::(anonymous namespace)::convertDecimalType>>(DB::Field const&, DB::DataTypeDecimal> const&) @ 0x0000000014c5e923 5. /build/src/Interpreters/convertFieldToType.cpp:253: DB::(anonymous namespace)::convertFieldToTypeImpl(DB::Field const&, DB::IDataType const&, DB::IDataType const*, DB::FormatSettings const&) @ 0x0000000014c588b4 6. /build/src/Interpreters/convertFieldToType.cpp:633: DB::convertFieldToType(DB::Field const&, DB::IDataType const&, DB::IDataType const*, DB::FormatSettings const&) @ 0x0000000014c57687 7. /build/src/Interpreters/convertFieldToType.cpp:643: DB::convertFieldToTypeOrThrow(DB::Field const&, DB::IDataType const&, DB::IDataType const*, DB::FormatSettings const&) @ 0x0000000014c5a598 8. /build/src/TableFunctions/TableFunctionValues.cpp:67: DB::(anonymous namespace)::TableFunctionValues::executeImpl(std::shared_ptr const&, std::shared_ptr, String const&, DB::ColumnsDescription, bool) const @ 0x000000001182e037 9. /build/src/TableFunctions/ITableFunction.cpp:36: DB::ITableFunction::execute(std::shared_ptr const&, std::shared_ptr, String const&, DB::ColumnsDescription, bool, bool) const @ 0x00000000131e9fc3 10. /build/src/Interpreters/Context.cpp:2501: DB::Context::executeTableFunction(std::shared_ptr const&, std::shared_ptr const&) @ 0x00000000144345b2 11. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:4975: DB::QueryAnalyzer::resolveTableFunction(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&, bool) @ 0x000000001401e9f9 12. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5342: DB::QueryAnalyzer::resolveQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&) @ 0x00000000140452bf 13. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5597: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000140136f0 14. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000140127f9 15. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000014011fce 16. /build/src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000001406ce8a 17. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000014973b42 18. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000001497268d 19. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000014974d24 20. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001492924b 21. /build/src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88641 22. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 23. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 24. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 25. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 26. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 27. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 28. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 29. ? @ 0x00007fbc6213eac3 30. ? @ 0x00007fbc621d0850 2025.07.28 11:56:29.909457 [ 11826 ] {155b6568-bd26-48b3-b471-7d62f3beeb2d} executeQuery: Code: 69. DB::Exception: Number is too big to place in Decimal(8, 8). (ARGUMENT_OUT_OF_BOUND) (version 25.3.6.10636.altinitytest (altinity build)) (from [::1]:37450) (comment: 01178_int_field_to_decimal.sql) (query 2, line 2) (in query: select d from values('d Decimal(8, 8)', 0, 2) where d not in (1, 0);), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x000000000a06b56b 4. /build/src/Interpreters/convertFieldToType.cpp:93: DB::Field DB::(anonymous namespace)::convertDecimalType>>(DB::Field const&, DB::DataTypeDecimal> const&) @ 0x0000000014c5e923 5. /build/src/Interpreters/convertFieldToType.cpp:253: DB::(anonymous namespace)::convertFieldToTypeImpl(DB::Field const&, DB::IDataType const&, DB::IDataType const*, DB::FormatSettings const&) @ 0x0000000014c588b4 6. /build/src/Interpreters/convertFieldToType.cpp:633: DB::convertFieldToType(DB::Field const&, DB::IDataType const&, DB::IDataType const*, DB::FormatSettings const&) @ 0x0000000014c57687 7. /build/src/Interpreters/convertFieldToType.cpp:643: DB::convertFieldToTypeOrThrow(DB::Field const&, DB::IDataType const&, DB::IDataType const*, DB::FormatSettings const&) @ 0x0000000014c5a598 8. /build/src/TableFunctions/TableFunctionValues.cpp:67: DB::(anonymous namespace)::TableFunctionValues::executeImpl(std::shared_ptr const&, std::shared_ptr, String const&, DB::ColumnsDescription, bool) const @ 0x000000001182e037 9. /build/src/TableFunctions/ITableFunction.cpp:36: DB::ITableFunction::execute(std::shared_ptr const&, std::shared_ptr, String const&, DB::ColumnsDescription, bool, bool) const @ 0x00000000131e9fc3 10. /build/src/Interpreters/Context.cpp:2501: DB::Context::executeTableFunction(std::shared_ptr const&, std::shared_ptr const&) @ 0x00000000144345b2 11. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:4975: DB::QueryAnalyzer::resolveTableFunction(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&, bool) @ 0x000000001401e9f9 12. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5342: DB::QueryAnalyzer::resolveQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&) @ 0x00000000140452bf 13. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5597: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000140136f0 14. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000140127f9 15. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000014011fce 16. /build/src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000001406ce8a 17. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000014973b42 18. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000001497268d 19. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000014974d24 20. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001492924b 21. /build/src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88641 22. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 23. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 24. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 25. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 26. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 27. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 28. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 29. ? @ 0x00007fbc6213eac3 30. ? @ 0x00007fbc621d0850 2025.07.28 11:56:29.913594 [ 11826 ] {} TCPHandler: Code: 69. DB::Exception: Number is too big to place in Decimal(8, 8). (ARGUMENT_OUT_OF_BOUND), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x000000000a06b56b 4. /build/src/Interpreters/convertFieldToType.cpp:93: DB::Field DB::(anonymous namespace)::convertDecimalType>>(DB::Field const&, DB::DataTypeDecimal> const&) @ 0x0000000014c5e923 5. /build/src/Interpreters/convertFieldToType.cpp:253: DB::(anonymous namespace)::convertFieldToTypeImpl(DB::Field const&, DB::IDataType const&, DB::IDataType const*, DB::FormatSettings const&) @ 0x0000000014c588b4 6. /build/src/Interpreters/convertFieldToType.cpp:633: DB::convertFieldToType(DB::Field const&, DB::IDataType const&, DB::IDataType const*, DB::FormatSettings const&) @ 0x0000000014c57687 7. /build/src/Interpreters/convertFieldToType.cpp:643: DB::convertFieldToTypeOrThrow(DB::Field const&, DB::IDataType const&, DB::IDataType const*, DB::FormatSettings const&) @ 0x0000000014c5a598 8. /build/src/TableFunctions/TableFunctionValues.cpp:67: DB::(anonymous namespace)::TableFunctionValues::executeImpl(std::shared_ptr const&, std::shared_ptr, String const&, DB::ColumnsDescription, bool) const @ 0x000000001182e037 9. /build/src/TableFunctions/ITableFunction.cpp:36: DB::ITableFunction::execute(std::shared_ptr const&, std::shared_ptr, String const&, DB::ColumnsDescription, bool, bool) const @ 0x00000000131e9fc3 10. /build/src/Interpreters/Context.cpp:2501: DB::Context::executeTableFunction(std::shared_ptr const&, std::shared_ptr const&) @ 0x00000000144345b2 11. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:4975: DB::QueryAnalyzer::resolveTableFunction(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&, bool) @ 0x000000001401e9f9 12. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5342: DB::QueryAnalyzer::resolveQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&) @ 0x00000000140452bf 13. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5597: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000140136f0 14. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000140127f9 15. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000014011fce 16. /build/src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000001406ce8a 17. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000014973b42 18. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000001497268d 19. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000014974d24 20. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001492924b 21. /build/src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88641 22. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 23. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 24. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 25. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 26. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 27. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 28. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 29. ? @ 0x00007fbc6213eac3 30. ? @ 0x00007fbc621d0850 2025.07.28 11:56:29.967763 [ 11826 ] {6db10209-e83f-4327-a556-173a381729b9} executeQuery: Code: 69. DB::Exception: Number is too big to place in Decimal(9, 8). (ARGUMENT_OUT_OF_BOUND) (version 25.3.6.10636.altinitytest (altinity build)) (from [::1]:37450) (comment: 01178_int_field_to_decimal.sql) (query 3, line 3) (in query: select d from values('d Decimal(9, 8)', 0, 3) where d not in (-9223372036854775808, 0);), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x000000000a06b56b 4. /build/src/Interpreters/convertFieldToType.cpp:93: DB::Field DB::(anonymous namespace)::convertDecimalType>>(DB::Field const&, DB::DataTypeDecimal> const&) @ 0x0000000014c5eb5c 5. /build/src/Interpreters/convertFieldToType.cpp:253: DB::(anonymous namespace)::convertFieldToTypeImpl(DB::Field const&, DB::IDataType const&, DB::IDataType const*, DB::FormatSettings const&) @ 0x0000000014c588b4 6. /build/src/Interpreters/convertFieldToType.cpp:633: DB::convertFieldToType(DB::Field const&, DB::IDataType const&, DB::IDataType const*, DB::FormatSettings const&) @ 0x0000000014c57687 7. /build/src/Interpreters/convertFieldToType.cpp:665: DB::convertFieldToTypeStrict(DB::Field const&, DB::IDataType const&, DB::IDataType const&, DB::FormatSettings const&) @ 0x0000000014c5a8c3 8. /build/src/Analyzer/SetUtils.cpp:69: DB::(anonymous namespace)::convertFieldToTypeCheckEnum(DB::Field const&, DB::IDataType const&, DB::IDataType const&, bool) @ 0x00000000142ca1c5 9. /build/src/Analyzer/SetUtils.cpp:99: DB::getSetElementsForConstantValue(std::shared_ptr const&, DB::Field const&, std::shared_ptr const&, DB::GetSetElementParams) @ 0x00000000142c7b91 10. /build/src/Planner/CollectSets.cpp:79: DB::(anonymous namespace)::CollectSetsVisitor::visitImpl(std::shared_ptr const&) @ 0x00000000142d23bb 11. /build/src/Analyzer/InDepthQueryTreeVisitor.h:63: DB::InDepthQueryTreeVisitor::visitChildren(std::shared_ptr const&) @ 0x00000000142d1f90 12. /build/src/Analyzer/InDepthQueryTreeVisitor.h:66: DB::collectSets(std::shared_ptr const&, DB::PlannerContext&) @ 0x00000000142d1f24 13. /build/src/Planner/Planner.cpp:1470: DB::Planner::buildPlanForQueryNode() @ 0x000000001497898c 14. /build/src/Planner/Planner.cpp:1308: DB::Planner::buildQueryPlanIfNeeded() @ 0x000000001497685c 15. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:255: DB::InterpreterSelectQueryAnalyzer::getQueryPlan() @ 0x000000001497476d 16. /build/src/Interpreters/executeQuery.cpp:1405: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88806 17. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 18. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 19. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 20. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 21. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 22. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 23. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 24. ? @ 0x00007fbc6213eac3 25. ? @ 0x00007fbc621d0850 2025.07.28 11:56:29.971472 [ 11826 ] {} TCPHandler: Code: 69. DB::Exception: Number is too big to place in Decimal(9, 8). (ARGUMENT_OUT_OF_BOUND), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x000000000a06b56b 4. /build/src/Interpreters/convertFieldToType.cpp:93: DB::Field DB::(anonymous namespace)::convertDecimalType>>(DB::Field const&, DB::DataTypeDecimal> const&) @ 0x0000000014c5eb5c 5. /build/src/Interpreters/convertFieldToType.cpp:253: DB::(anonymous namespace)::convertFieldToTypeImpl(DB::Field const&, DB::IDataType const&, DB::IDataType const*, DB::FormatSettings const&) @ 0x0000000014c588b4 6. /build/src/Interpreters/convertFieldToType.cpp:633: DB::convertFieldToType(DB::Field const&, DB::IDataType const&, DB::IDataType const*, DB::FormatSettings const&) @ 0x0000000014c57687 7. /build/src/Interpreters/convertFieldToType.cpp:665: DB::convertFieldToTypeStrict(DB::Field const&, DB::IDataType const&, DB::IDataType const&, DB::FormatSettings const&) @ 0x0000000014c5a8c3 8. /build/src/Analyzer/SetUtils.cpp:69: DB::(anonymous namespace)::convertFieldToTypeCheckEnum(DB::Field const&, DB::IDataType const&, DB::IDataType const&, bool) @ 0x00000000142ca1c5 9. /build/src/Analyzer/SetUtils.cpp:99: DB::getSetElementsForConstantValue(std::shared_ptr const&, DB::Field const&, std::shared_ptr const&, DB::GetSetElementParams) @ 0x00000000142c7b91 10. /build/src/Planner/CollectSets.cpp:79: DB::(anonymous namespace)::CollectSetsVisitor::visitImpl(std::shared_ptr const&) @ 0x00000000142d23bb 11. /build/src/Analyzer/InDepthQueryTreeVisitor.h:63: DB::InDepthQueryTreeVisitor::visitChildren(std::shared_ptr const&) @ 0x00000000142d1f90 12. /build/src/Analyzer/InDepthQueryTreeVisitor.h:66: DB::collectSets(std::shared_ptr const&, DB::PlannerContext&) @ 0x00000000142d1f24 13. /build/src/Planner/Planner.cpp:1470: DB::Planner::buildPlanForQueryNode() @ 0x000000001497898c 14. /build/src/Planner/Planner.cpp:1308: DB::Planner::buildQueryPlanIfNeeded() @ 0x000000001497685c 15. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:255: DB::InterpreterSelectQueryAnalyzer::getQueryPlan() @ 0x000000001497476d 16. /build/src/Interpreters/executeQuery.cpp:1405: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88806 17. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 18. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 19. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 20. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 21. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 22. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 23. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 24. ? @ 0x00007fbc6213eac3 25. ? @ 0x00007fbc621d0850 2025.07.28 11:56:30.125719 [ 11826 ] {7720ec4d-0247-4e7c-9f81-d1dd6d6c4598} executeQuery: Code: 69. DB::Exception: Number is too big to place in Decimal(9, 8). (ARGUMENT_OUT_OF_BOUND) (version 25.3.6.10636.altinitytest (altinity build)) (from [::1]:37450) (comment: 01178_int_field_to_decimal.sql) (query 4, line 4) (in query: select d from values('d Decimal(9, 8)', 0, 4) where d not in (18446744073709551615, 0);), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x000000000a06b56b 4. /build/src/Interpreters/convertFieldToType.cpp:93: DB::Field DB::(anonymous namespace)::convertDecimalType>>(DB::Field const&, DB::DataTypeDecimal> const&) @ 0x0000000014c5e923 5. /build/src/Interpreters/convertFieldToType.cpp:253: DB::(anonymous namespace)::convertFieldToTypeImpl(DB::Field const&, DB::IDataType const&, DB::IDataType const*, DB::FormatSettings const&) @ 0x0000000014c588b4 6. /build/src/Interpreters/convertFieldToType.cpp:633: DB::convertFieldToType(DB::Field const&, DB::IDataType const&, DB::IDataType const*, DB::FormatSettings const&) @ 0x0000000014c57687 7. /build/src/Interpreters/convertFieldToType.cpp:665: DB::convertFieldToTypeStrict(DB::Field const&, DB::IDataType const&, DB::IDataType const&, DB::FormatSettings const&) @ 0x0000000014c5a8c3 8. /build/src/Analyzer/SetUtils.cpp:69: DB::(anonymous namespace)::convertFieldToTypeCheckEnum(DB::Field const&, DB::IDataType const&, DB::IDataType const&, bool) @ 0x00000000142ca1c5 9. /build/src/Analyzer/SetUtils.cpp:99: DB::getSetElementsForConstantValue(std::shared_ptr const&, DB::Field const&, std::shared_ptr const&, DB::GetSetElementParams) @ 0x00000000142c7b91 10. /build/src/Planner/CollectSets.cpp:79: DB::(anonymous namespace)::CollectSetsVisitor::visitImpl(std::shared_ptr const&) @ 0x00000000142d23bb 11. /build/src/Analyzer/InDepthQueryTreeVisitor.h:63: DB::InDepthQueryTreeVisitor::visitChildren(std::shared_ptr const&) @ 0x00000000142d1f90 12. /build/src/Analyzer/InDepthQueryTreeVisitor.h:66: DB::collectSets(std::shared_ptr const&, DB::PlannerContext&) @ 0x00000000142d1f24 13. /build/src/Planner/Planner.cpp:1470: DB::Planner::buildPlanForQueryNode() @ 0x000000001497898c 14. /build/src/Planner/Planner.cpp:1308: DB::Planner::buildQueryPlanIfNeeded() @ 0x000000001497685c 15. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:255: DB::InterpreterSelectQueryAnalyzer::getQueryPlan() @ 0x000000001497476d 16. /build/src/Interpreters/executeQuery.cpp:1405: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88806 17. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 18. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 19. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 20. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 21. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 22. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 23. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 24. ? @ 0x00007fbc6213eac3 25. ? @ 0x00007fbc621d0850 2025.07.28 11:56:30.131617 [ 11826 ] {} TCPHandler: Code: 69. DB::Exception: Number is too big to place in Decimal(9, 8). (ARGUMENT_OUT_OF_BOUND), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x000000000a06b56b 4. /build/src/Interpreters/convertFieldToType.cpp:93: DB::Field DB::(anonymous namespace)::convertDecimalType>>(DB::Field const&, DB::DataTypeDecimal> const&) @ 0x0000000014c5e923 5. /build/src/Interpreters/convertFieldToType.cpp:253: DB::(anonymous namespace)::convertFieldToTypeImpl(DB::Field const&, DB::IDataType const&, DB::IDataType const*, DB::FormatSettings const&) @ 0x0000000014c588b4 6. /build/src/Interpreters/convertFieldToType.cpp:633: DB::convertFieldToType(DB::Field const&, DB::IDataType const&, DB::IDataType const*, DB::FormatSettings const&) @ 0x0000000014c57687 7. /build/src/Interpreters/convertFieldToType.cpp:665: DB::convertFieldToTypeStrict(DB::Field const&, DB::IDataType const&, DB::IDataType const&, DB::FormatSettings const&) @ 0x0000000014c5a8c3 8. /build/src/Analyzer/SetUtils.cpp:69: DB::(anonymous namespace)::convertFieldToTypeCheckEnum(DB::Field const&, DB::IDataType const&, DB::IDataType const&, bool) @ 0x00000000142ca1c5 9. /build/src/Analyzer/SetUtils.cpp:99: DB::getSetElementsForConstantValue(std::shared_ptr const&, DB::Field const&, std::shared_ptr const&, DB::GetSetElementParams) @ 0x00000000142c7b91 10. /build/src/Planner/CollectSets.cpp:79: DB::(anonymous namespace)::CollectSetsVisitor::visitImpl(std::shared_ptr const&) @ 0x00000000142d23bb 11. /build/src/Analyzer/InDepthQueryTreeVisitor.h:63: DB::InDepthQueryTreeVisitor::visitChildren(std::shared_ptr const&) @ 0x00000000142d1f90 12. /build/src/Analyzer/InDepthQueryTreeVisitor.h:66: DB::collectSets(std::shared_ptr const&, DB::PlannerContext&) @ 0x00000000142d1f24 13. /build/src/Planner/Planner.cpp:1470: DB::Planner::buildPlanForQueryNode() @ 0x000000001497898c 14. /build/src/Planner/Planner.cpp:1308: DB::Planner::buildQueryPlanIfNeeded() @ 0x000000001497685c 15. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:255: DB::InterpreterSelectQueryAnalyzer::getQueryPlan() @ 0x000000001497476d 16. /build/src/Interpreters/executeQuery.cpp:1405: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88806 17. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 18. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 19. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 20. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 21. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 22. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 23. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 24. ? @ 0x00007fbc6213eac3 25. ? @ 0x00007fbc621d0850 2025.07.28 11:56:30.413820 [ 11826 ] {07db9257-14e0-4b19-8c3c-1dd745aa3bc0} executeQuery: Code: 69. DB::Exception: Number is too big to place in Decimal(18, 8). (ARGUMENT_OUT_OF_BOUND) (version 25.3.6.10636.altinitytest (altinity build)) (from [::1]:37450) (comment: 01178_int_field_to_decimal.sql) (query 5, line 5) (in query: select d from values('d Decimal(18, 8)', 0, 5) where d not in (-9223372036854775808, 0);), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x000000000a06b56b 4. /build/src/Interpreters/convertFieldToType.cpp:93: DB::Field DB::(anonymous namespace)::convertDecimalType>>(DB::Field const&, DB::DataTypeDecimal> const&) @ 0x0000000014c5f25b 5. /build/src/Interpreters/convertFieldToType.cpp:255: DB::(anonymous namespace)::convertFieldToTypeImpl(DB::Field const&, DB::IDataType const&, DB::IDataType const*, DB::FormatSettings const&) @ 0x0000000014c58df4 6. /build/src/Interpreters/convertFieldToType.cpp:633: DB::convertFieldToType(DB::Field const&, DB::IDataType const&, DB::IDataType const*, DB::FormatSettings const&) @ 0x0000000014c57687 7. /build/src/Interpreters/convertFieldToType.cpp:665: DB::convertFieldToTypeStrict(DB::Field const&, DB::IDataType const&, DB::IDataType const&, DB::FormatSettings const&) @ 0x0000000014c5a8c3 8. /build/src/Analyzer/SetUtils.cpp:69: DB::(anonymous namespace)::convertFieldToTypeCheckEnum(DB::Field const&, DB::IDataType const&, DB::IDataType const&, bool) @ 0x00000000142ca1c5 9. /build/src/Analyzer/SetUtils.cpp:99: DB::getSetElementsForConstantValue(std::shared_ptr const&, DB::Field const&, std::shared_ptr const&, DB::GetSetElementParams) @ 0x00000000142c7b91 10. /build/src/Planner/CollectSets.cpp:79: DB::(anonymous namespace)::CollectSetsVisitor::visitImpl(std::shared_ptr const&) @ 0x00000000142d23bb 11. /build/src/Analyzer/InDepthQueryTreeVisitor.h:63: DB::InDepthQueryTreeVisitor::visitChildren(std::shared_ptr const&) @ 0x00000000142d1f90 12. /build/src/Analyzer/InDepthQueryTreeVisitor.h:66: DB::collectSets(std::shared_ptr const&, DB::PlannerContext&) @ 0x00000000142d1f24 13. /build/src/Planner/Planner.cpp:1470: DB::Planner::buildPlanForQueryNode() @ 0x000000001497898c 14. /build/src/Planner/Planner.cpp:1308: DB::Planner::buildQueryPlanIfNeeded() @ 0x000000001497685c 15. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:255: DB::InterpreterSelectQueryAnalyzer::getQueryPlan() @ 0x000000001497476d 16. /build/src/Interpreters/executeQuery.cpp:1405: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88806 17. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 18. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 19. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 20. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 21. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 22. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 23. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 24. ? @ 0x00007fbc6213eac3 25. ? @ 0x00007fbc621d0850 2025.07.28 11:56:30.434632 [ 11826 ] {} TCPHandler: Code: 69. DB::Exception: Number is too big to place in Decimal(18, 8). (ARGUMENT_OUT_OF_BOUND), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x000000000a06b56b 4. /build/src/Interpreters/convertFieldToType.cpp:93: DB::Field DB::(anonymous namespace)::convertDecimalType>>(DB::Field const&, DB::DataTypeDecimal> const&) @ 0x0000000014c5f25b 5. /build/src/Interpreters/convertFieldToType.cpp:255: DB::(anonymous namespace)::convertFieldToTypeImpl(DB::Field const&, DB::IDataType const&, DB::IDataType const*, DB::FormatSettings const&) @ 0x0000000014c58df4 6. /build/src/Interpreters/convertFieldToType.cpp:633: DB::convertFieldToType(DB::Field const&, DB::IDataType const&, DB::IDataType const*, DB::FormatSettings const&) @ 0x0000000014c57687 7. /build/src/Interpreters/convertFieldToType.cpp:665: DB::convertFieldToTypeStrict(DB::Field const&, DB::IDataType const&, DB::IDataType const&, DB::FormatSettings const&) @ 0x0000000014c5a8c3 8. /build/src/Analyzer/SetUtils.cpp:69: DB::(anonymous namespace)::convertFieldToTypeCheckEnum(DB::Field const&, DB::IDataType const&, DB::IDataType const&, bool) @ 0x00000000142ca1c5 9. /build/src/Analyzer/SetUtils.cpp:99: DB::getSetElementsForConstantValue(std::shared_ptr const&, DB::Field const&, std::shared_ptr const&, DB::GetSetElementParams) @ 0x00000000142c7b91 10. /build/src/Planner/CollectSets.cpp:79: DB::(anonymous namespace)::CollectSetsVisitor::visitImpl(std::shared_ptr const&) @ 0x00000000142d23bb 11. /build/src/Analyzer/InDepthQueryTreeVisitor.h:63: DB::InDepthQueryTreeVisitor::visitChildren(std::shared_ptr const&) @ 0x00000000142d1f90 12. /build/src/Analyzer/InDepthQueryTreeVisitor.h:66: DB::collectSets(std::shared_ptr const&, DB::PlannerContext&) @ 0x00000000142d1f24 13. /build/src/Planner/Planner.cpp:1470: DB::Planner::buildPlanForQueryNode() @ 0x000000001497898c 14. /build/src/Planner/Planner.cpp:1308: DB::Planner::buildQueryPlanIfNeeded() @ 0x000000001497685c 15. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:255: DB::InterpreterSelectQueryAnalyzer::getQueryPlan() @ 0x000000001497476d 16. /build/src/Interpreters/executeQuery.cpp:1405: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88806 17. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 18. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 19. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 20. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 21. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 22. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 23. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 24. ? @ 0x00007fbc6213eac3 25. ? @ 0x00007fbc621d0850 2025.07.28 11:56:30.435354 [ 3976 ] {} test_13.rmt2 (7f9b740d-015c-470e-8cc6-8ba33be0dc63): auto DB::StorageReplicatedMergeTree::processQueueEntry(ReplicatedMergeTreeQueue::SelectedEntryPtr)::(anonymous class)::operator()(LogEntryPtr &) const: Code: 86. DB::HTTPException: Received error from remote server http://146b4357c08d:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Ftest%2F01165%2Ftest_13%2Frmt%2Freplicas%2F1&part=20250728_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.6.10636.altinitytest (altinity build)) '. (RECEIVED_ERROR_FROM_REMOTE_IO_SERVER), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.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 const&, int&&, String const&, unsigned long&&, String const&) @ 0x000000000feda8d9 4. /build/src/IO/HTTPCommon.cpp:104: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x000000000feda6e2 5. /build/src/IO/HTTPCommon.cpp:93: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x000000000feda537 6. /build/src/IO/ReadWriteBufferFromHTTP.cpp:277: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x000000001184a4c4 7. /build/src/IO/ReadWriteBufferFromHTTP.cpp:285: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x000000001184a615 8. /build/src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x000000001184ae59 9. /build/src/IO/ReadWriteBufferFromHTTP.cpp:472: void std::__function::__policy_invoker::__call_impl[abi:se190107]>(std::__function::__policy_storage const*) @ 0x000000001184cedd 10. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001184858b 11. /build/src/IO/ReadWriteBufferFromHTTP.cpp:465: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x000000001184bf0b 12. /build/src/IO/ReadBuffer.h:60: DB::ReadBuffer::next() @ 0x000000000a148c7b 13. /build/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) @ 0x0000000011849fb2 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]>&)>&, 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&) @ 0x0000000011841980 15. /build/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) @ 0x000000001621208e 16. /build/src/Storages/StorageReplicatedMergeTree.cpp:5228: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl[abi:se190107] const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000015f9a5fe 17. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000015ed8bfd 18. /build/src/Storages/StorageReplicatedMergeTree.cpp:2514: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x0000000015ec9aab 19. /build/src/Storages/StorageReplicatedMergeTree.cpp:2349: DB::StorageReplicatedMergeTree::executeLogEntry(DB::ReplicatedMergeTreeLogEntry&) @ 0x0000000015eba91b 20. /build/src/Storages/StorageReplicatedMergeTree.cpp:3876: bool std::__function::__policy_invoker&)>::__call_impl[abi:se190107])::$_1, bool (std::shared_ptr&)>>(std::__function::__policy_storage const*, std::shared_ptr&) @ 0x0000000015f9837e 21. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000165d6fc3 22. /build/src/Storages/StorageReplicatedMergeTree.cpp:3872: DB::StorageReplicatedMergeTree::processQueueEntry(std::shared_ptr) @ 0x0000000015efc18a 23. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001624c1b2 24. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000162f9c70 25. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x00000000162fa55a 26. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc6653 27. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000000fccc4c3 28. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc3d92 29. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fcca080 30. ? @ 0x00007fbc6213eac3 31. ? @ 0x00007fbc621d0850 (version 25.3.6.10636.altinitytest (altinity build)) 2025.07.28 11:56:30.588673 [ 11826 ] {2d0a93d9-7761-4153-9043-e9c43135a65a} executeQuery: Code: 69. DB::Exception: Number is too big to place in Decimal(18, 8). (ARGUMENT_OUT_OF_BOUND) (version 25.3.6.10636.altinitytest (altinity build)) (from [::1]:37450) (comment: 01178_int_field_to_decimal.sql) (query 6, line 6) (in query: select d from values('d Decimal(18, 8)', 0, 6) where d not in (18446744073709551615, 0);), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x000000000a06b56b 4. /build/src/Interpreters/convertFieldToType.cpp:93: DB::Field DB::(anonymous namespace)::convertDecimalType>>(DB::Field const&, DB::DataTypeDecimal> const&) @ 0x0000000014c5f023 5. /build/src/Interpreters/convertFieldToType.cpp:255: DB::(anonymous namespace)::convertFieldToTypeImpl(DB::Field const&, DB::IDataType const&, DB::IDataType const*, DB::FormatSettings const&) @ 0x0000000014c58df4 6. /build/src/Interpreters/convertFieldToType.cpp:633: DB::convertFieldToType(DB::Field const&, DB::IDataType const&, DB::IDataType const*, DB::FormatSettings const&) @ 0x0000000014c57687 7. /build/src/Interpreters/convertFieldToType.cpp:665: DB::convertFieldToTypeStrict(DB::Field const&, DB::IDataType const&, DB::IDataType const&, DB::FormatSettings const&) @ 0x0000000014c5a8c3 8. /build/src/Analyzer/SetUtils.cpp:69: DB::(anonymous namespace)::convertFieldToTypeCheckEnum(DB::Field const&, DB::IDataType const&, DB::IDataType const&, bool) @ 0x00000000142ca1c5 9. /build/src/Analyzer/SetUtils.cpp:99: DB::getSetElementsForConstantValue(std::shared_ptr const&, DB::Field const&, std::shared_ptr const&, DB::GetSetElementParams) @ 0x00000000142c7b91 10. /build/src/Planner/CollectSets.cpp:79: DB::(anonymous namespace)::CollectSetsVisitor::visitImpl(std::shared_ptr const&) @ 0x00000000142d23bb 11. /build/src/Analyzer/InDepthQueryTreeVisitor.h:63: DB::InDepthQueryTreeVisitor::visitChildren(std::shared_ptr const&) @ 0x00000000142d1f90 12. /build/src/Analyzer/InDepthQueryTreeVisitor.h:66: DB::collectSets(std::shared_ptr const&, DB::PlannerContext&) @ 0x00000000142d1f24 13. /build/src/Planner/Planner.cpp:1470: DB::Planner::buildPlanForQueryNode() @ 0x000000001497898c 14. /build/src/Planner/Planner.cpp:1308: DB::Planner::buildQueryPlanIfNeeded() @ 0x000000001497685c 15. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:255: DB::InterpreterSelectQueryAnalyzer::getQueryPlan() @ 0x000000001497476d 16. /build/src/Interpreters/executeQuery.cpp:1405: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88806 17. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 18. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 19. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 20. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 21. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 22. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 23. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 24. ? @ 0x00007fbc6213eac3 25. ? @ 0x00007fbc621d0850 2025.07.28 11:56:30.592277 [ 11826 ] {} TCPHandler: Code: 69. DB::Exception: Number is too big to place in Decimal(18, 8). (ARGUMENT_OUT_OF_BOUND), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x000000000a06b56b 4. /build/src/Interpreters/convertFieldToType.cpp:93: DB::Field DB::(anonymous namespace)::convertDecimalType>>(DB::Field const&, DB::DataTypeDecimal> const&) @ 0x0000000014c5f023 5. /build/src/Interpreters/convertFieldToType.cpp:255: DB::(anonymous namespace)::convertFieldToTypeImpl(DB::Field const&, DB::IDataType const&, DB::IDataType const*, DB::FormatSettings const&) @ 0x0000000014c58df4 6. /build/src/Interpreters/convertFieldToType.cpp:633: DB::convertFieldToType(DB::Field const&, DB::IDataType const&, DB::IDataType const*, DB::FormatSettings const&) @ 0x0000000014c57687 7. /build/src/Interpreters/convertFieldToType.cpp:665: DB::convertFieldToTypeStrict(DB::Field const&, DB::IDataType const&, DB::IDataType const&, DB::FormatSettings const&) @ 0x0000000014c5a8c3 8. /build/src/Analyzer/SetUtils.cpp:69: DB::(anonymous namespace)::convertFieldToTypeCheckEnum(DB::Field const&, DB::IDataType const&, DB::IDataType const&, bool) @ 0x00000000142ca1c5 9. /build/src/Analyzer/SetUtils.cpp:99: DB::getSetElementsForConstantValue(std::shared_ptr const&, DB::Field const&, std::shared_ptr const&, DB::GetSetElementParams) @ 0x00000000142c7b91 10. /build/src/Planner/CollectSets.cpp:79: DB::(anonymous namespace)::CollectSetsVisitor::visitImpl(std::shared_ptr const&) @ 0x00000000142d23bb 11. /build/src/Analyzer/InDepthQueryTreeVisitor.h:63: DB::InDepthQueryTreeVisitor::visitChildren(std::shared_ptr const&) @ 0x00000000142d1f90 12. /build/src/Analyzer/InDepthQueryTreeVisitor.h:66: DB::collectSets(std::shared_ptr const&, DB::PlannerContext&) @ 0x00000000142d1f24 13. /build/src/Planner/Planner.cpp:1470: DB::Planner::buildPlanForQueryNode() @ 0x000000001497898c 14. /build/src/Planner/Planner.cpp:1308: DB::Planner::buildQueryPlanIfNeeded() @ 0x000000001497685c 15. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:255: DB::InterpreterSelectQueryAnalyzer::getQueryPlan() @ 0x000000001497476d 16. /build/src/Interpreters/executeQuery.cpp:1405: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88806 17. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 18. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 19. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 20. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 21. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 22. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 23. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 24. ? @ 0x00007fbc6213eac3 25. ? @ 0x00007fbc621d0850 2025.07.28 11:56:30.695012 [ 11826 ] {3f348a5e-d03f-47d4-a495-67a6d4c84e64} executeQuery: Code: 69. DB::Exception: Number is too big to place in Decimal(26, 8). (ARGUMENT_OUT_OF_BOUND) (version 25.3.6.10636.altinitytest (altinity build)) (from [::1]:37450) (comment: 01178_int_field_to_decimal.sql) (query 7, line 7) (in query: select d from values('d Decimal(26, 8)', 0, 7) where d not in (-9223372036854775808, 0);), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x000000000a06b56b 4. /build/src/Interpreters/convertFieldToType.cpp:93: DB::Field DB::(anonymous namespace)::convertDecimalType>>>(DB::Field const&, DB::DataTypeDecimal>> const&) @ 0x0000000014c5fdb4 5. /build/src/Interpreters/convertFieldToType.cpp:257: DB::(anonymous namespace)::convertFieldToTypeImpl(DB::Field const&, DB::IDataType const&, DB::IDataType const*, DB::FormatSettings const&) @ 0x0000000014c58ffb 6. /build/src/Interpreters/convertFieldToType.cpp:633: DB::convertFieldToType(DB::Field const&, DB::IDataType const&, DB::IDataType const*, DB::FormatSettings const&) @ 0x0000000014c57687 7. /build/src/Interpreters/convertFieldToType.cpp:665: DB::convertFieldToTypeStrict(DB::Field const&, DB::IDataType const&, DB::IDataType const&, DB::FormatSettings const&) @ 0x0000000014c5a8c3 8. /build/src/Analyzer/SetUtils.cpp:69: DB::(anonymous namespace)::convertFieldToTypeCheckEnum(DB::Field const&, DB::IDataType const&, DB::IDataType const&, bool) @ 0x00000000142ca1c5 9. /build/src/Analyzer/SetUtils.cpp:99: DB::getSetElementsForConstantValue(std::shared_ptr const&, DB::Field const&, std::shared_ptr const&, DB::GetSetElementParams) @ 0x00000000142c7b91 10. /build/src/Planner/CollectSets.cpp:79: DB::(anonymous namespace)::CollectSetsVisitor::visitImpl(std::shared_ptr const&) @ 0x00000000142d23bb 11. /build/src/Analyzer/InDepthQueryTreeVisitor.h:63: DB::InDepthQueryTreeVisitor::visitChildren(std::shared_ptr const&) @ 0x00000000142d1f90 12. /build/src/Analyzer/InDepthQueryTreeVisitor.h:66: DB::collectSets(std::shared_ptr const&, DB::PlannerContext&) @ 0x00000000142d1f24 13. /build/src/Planner/Planner.cpp:1470: DB::Planner::buildPlanForQueryNode() @ 0x000000001497898c 14. /build/src/Planner/Planner.cpp:1308: DB::Planner::buildQueryPlanIfNeeded() @ 0x000000001497685c 15. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:255: DB::InterpreterSelectQueryAnalyzer::getQueryPlan() @ 0x000000001497476d 16. /build/src/Interpreters/executeQuery.cpp:1405: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88806 17. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 18. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 19. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 20. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 21. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 22. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 23. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 24. ? @ 0x00007fbc6213eac3 25. ? @ 0x00007fbc621d0850 2025.07.28 11:56:30.710368 [ 11826 ] {} TCPHandler: Code: 69. DB::Exception: Number is too big to place in Decimal(26, 8). (ARGUMENT_OUT_OF_BOUND), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x000000000a06b56b 4. /build/src/Interpreters/convertFieldToType.cpp:93: DB::Field DB::(anonymous namespace)::convertDecimalType>>>(DB::Field const&, DB::DataTypeDecimal>> const&) @ 0x0000000014c5fdb4 5. /build/src/Interpreters/convertFieldToType.cpp:257: DB::(anonymous namespace)::convertFieldToTypeImpl(DB::Field const&, DB::IDataType const&, DB::IDataType const*, DB::FormatSettings const&) @ 0x0000000014c58ffb 6. /build/src/Interpreters/convertFieldToType.cpp:633: DB::convertFieldToType(DB::Field const&, DB::IDataType const&, DB::IDataType const*, DB::FormatSettings const&) @ 0x0000000014c57687 7. /build/src/Interpreters/convertFieldToType.cpp:665: DB::convertFieldToTypeStrict(DB::Field const&, DB::IDataType const&, DB::IDataType const&, DB::FormatSettings const&) @ 0x0000000014c5a8c3 8. /build/src/Analyzer/SetUtils.cpp:69: DB::(anonymous namespace)::convertFieldToTypeCheckEnum(DB::Field const&, DB::IDataType const&, DB::IDataType const&, bool) @ 0x00000000142ca1c5 9. /build/src/Analyzer/SetUtils.cpp:99: DB::getSetElementsForConstantValue(std::shared_ptr const&, DB::Field const&, std::shared_ptr const&, DB::GetSetElementParams) @ 0x00000000142c7b91 10. /build/src/Planner/CollectSets.cpp:79: DB::(anonymous namespace)::CollectSetsVisitor::visitImpl(std::shared_ptr const&) @ 0x00000000142d23bb 11. /build/src/Analyzer/InDepthQueryTreeVisitor.h:63: DB::InDepthQueryTreeVisitor::visitChildren(std::shared_ptr const&) @ 0x00000000142d1f90 12. /build/src/Analyzer/InDepthQueryTreeVisitor.h:66: DB::collectSets(std::shared_ptr const&, DB::PlannerContext&) @ 0x00000000142d1f24 13. /build/src/Planner/Planner.cpp:1470: DB::Planner::buildPlanForQueryNode() @ 0x000000001497898c 14. /build/src/Planner/Planner.cpp:1308: DB::Planner::buildQueryPlanIfNeeded() @ 0x000000001497685c 15. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:255: DB::InterpreterSelectQueryAnalyzer::getQueryPlan() @ 0x000000001497476d 16. /build/src/Interpreters/executeQuery.cpp:1405: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88806 17. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 18. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 19. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 20. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 21. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 22. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 23. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 24. ? @ 0x00007fbc6213eac3 25. ? @ 0x00007fbc621d0850 2025.07.28 11:56:30.750433 [ 11826 ] {933d99d3-6e3a-4553-a5df-fd9352a90058} executeQuery: Code: 69. DB::Exception: Number is too big to place in Decimal(27, 8). (ARGUMENT_OUT_OF_BOUND) (version 25.3.6.10636.altinitytest (altinity build)) (from [::1]:37450) (comment: 01178_int_field_to_decimal.sql) (query 8, line 8) (in query: select d from values('d Decimal(27, 8)', 0, 8) where d not in (18446744073709551615, 0);), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x000000000a06b56b 4. /build/src/Interpreters/convertFieldToType.cpp:93: DB::Field DB::(anonymous namespace)::convertDecimalType>>>(DB::Field const&, DB::DataTypeDecimal>> const&) @ 0x0000000014c5fc0f 5. /build/src/Interpreters/convertFieldToType.cpp:257: DB::(anonymous namespace)::convertFieldToTypeImpl(DB::Field const&, DB::IDataType const&, DB::IDataType const*, DB::FormatSettings const&) @ 0x0000000014c58ffb 6. /build/src/Interpreters/convertFieldToType.cpp:633: DB::convertFieldToType(DB::Field const&, DB::IDataType const&, DB::IDataType const*, DB::FormatSettings const&) @ 0x0000000014c57687 7. /build/src/Interpreters/convertFieldToType.cpp:665: DB::convertFieldToTypeStrict(DB::Field const&, DB::IDataType const&, DB::IDataType const&, DB::FormatSettings const&) @ 0x0000000014c5a8c3 8. /build/src/Analyzer/SetUtils.cpp:69: DB::(anonymous namespace)::convertFieldToTypeCheckEnum(DB::Field const&, DB::IDataType const&, DB::IDataType const&, bool) @ 0x00000000142ca1c5 9. /build/src/Analyzer/SetUtils.cpp:99: DB::getSetElementsForConstantValue(std::shared_ptr const&, DB::Field const&, std::shared_ptr const&, DB::GetSetElementParams) @ 0x00000000142c7b91 10. /build/src/Planner/CollectSets.cpp:79: DB::(anonymous namespace)::CollectSetsVisitor::visitImpl(std::shared_ptr const&) @ 0x00000000142d23bb 11. /build/src/Analyzer/InDepthQueryTreeVisitor.h:63: DB::InDepthQueryTreeVisitor::visitChildren(std::shared_ptr const&) @ 0x00000000142d1f90 12. /build/src/Analyzer/InDepthQueryTreeVisitor.h:66: DB::collectSets(std::shared_ptr const&, DB::PlannerContext&) @ 0x00000000142d1f24 13. /build/src/Planner/Planner.cpp:1470: DB::Planner::buildPlanForQueryNode() @ 0x000000001497898c 14. /build/src/Planner/Planner.cpp:1308: DB::Planner::buildQueryPlanIfNeeded() @ 0x000000001497685c 15. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:255: DB::InterpreterSelectQueryAnalyzer::getQueryPlan() @ 0x000000001497476d 16. /build/src/Interpreters/executeQuery.cpp:1405: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88806 17. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 18. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 19. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 20. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 21. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 22. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 23. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 24. ? @ 0x00007fbc6213eac3 25. ? @ 0x00007fbc621d0850 2025.07.28 11:56:30.754318 [ 11826 ] {} TCPHandler: Code: 69. DB::Exception: Number is too big to place in Decimal(27, 8). (ARGUMENT_OUT_OF_BOUND), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x000000000a06b56b 4. /build/src/Interpreters/convertFieldToType.cpp:93: DB::Field DB::(anonymous namespace)::convertDecimalType>>>(DB::Field const&, DB::DataTypeDecimal>> const&) @ 0x0000000014c5fc0f 5. /build/src/Interpreters/convertFieldToType.cpp:257: DB::(anonymous namespace)::convertFieldToTypeImpl(DB::Field const&, DB::IDataType const&, DB::IDataType const*, DB::FormatSettings const&) @ 0x0000000014c58ffb 6. /build/src/Interpreters/convertFieldToType.cpp:633: DB::convertFieldToType(DB::Field const&, DB::IDataType const&, DB::IDataType const*, DB::FormatSettings const&) @ 0x0000000014c57687 7. /build/src/Interpreters/convertFieldToType.cpp:665: DB::convertFieldToTypeStrict(DB::Field const&, DB::IDataType const&, DB::IDataType const&, DB::FormatSettings const&) @ 0x0000000014c5a8c3 8. /build/src/Analyzer/SetUtils.cpp:69: DB::(anonymous namespace)::convertFieldToTypeCheckEnum(DB::Field const&, DB::IDataType const&, DB::IDataType const&, bool) @ 0x00000000142ca1c5 9. /build/src/Analyzer/SetUtils.cpp:99: DB::getSetElementsForConstantValue(std::shared_ptr const&, DB::Field const&, std::shared_ptr const&, DB::GetSetElementParams) @ 0x00000000142c7b91 10. /build/src/Planner/CollectSets.cpp:79: DB::(anonymous namespace)::CollectSetsVisitor::visitImpl(std::shared_ptr const&) @ 0x00000000142d23bb 11. /build/src/Analyzer/InDepthQueryTreeVisitor.h:63: DB::InDepthQueryTreeVisitor::visitChildren(std::shared_ptr const&) @ 0x00000000142d1f90 12. /build/src/Analyzer/InDepthQueryTreeVisitor.h:66: DB::collectSets(std::shared_ptr const&, DB::PlannerContext&) @ 0x00000000142d1f24 13. /build/src/Planner/Planner.cpp:1470: DB::Planner::buildPlanForQueryNode() @ 0x000000001497898c 14. /build/src/Planner/Planner.cpp:1308: DB::Planner::buildQueryPlanIfNeeded() @ 0x000000001497685c 15. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:255: DB::InterpreterSelectQueryAnalyzer::getQueryPlan() @ 0x000000001497476d 16. /build/src/Interpreters/executeQuery.cpp:1405: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88806 17. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 18. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 19. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 20. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 21. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 22. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 23. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 24. ? @ 0x00007fbc6213eac3 25. ? @ 0x00007fbc621d0850 2025.07.28 11:56:30.769315 [ 3963 ] {} test_13.rmt2 (7f9b740d-015c-470e-8cc6-8ba33be0dc63): auto DB::StorageReplicatedMergeTree::processQueueEntry(ReplicatedMergeTreeQueue::SelectedEntryPtr)::(anonymous class)::operator()(LogEntryPtr &) const: Code: 86. DB::HTTPException: Received error from remote server http://146b4357c08d:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Ftest%2F01165%2Ftest_13%2Frmt%2Freplicas%2F1&part=20250728_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.6.10636.altinitytest (altinity build)) '. (RECEIVED_ERROR_FROM_REMOTE_IO_SERVER), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.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 const&, int&&, String const&, unsigned long&&, String const&) @ 0x000000000feda8d9 4. /build/src/IO/HTTPCommon.cpp:104: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x000000000feda6e2 5. /build/src/IO/HTTPCommon.cpp:93: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x000000000feda537 6. /build/src/IO/ReadWriteBufferFromHTTP.cpp:277: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x000000001184a4c4 7. /build/src/IO/ReadWriteBufferFromHTTP.cpp:285: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x000000001184a615 8. /build/src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x000000001184ae59 9. /build/src/IO/ReadWriteBufferFromHTTP.cpp:472: void std::__function::__policy_invoker::__call_impl[abi:se190107]>(std::__function::__policy_storage const*) @ 0x000000001184cedd 10. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001184858b 11. /build/src/IO/ReadWriteBufferFromHTTP.cpp:465: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x000000001184bf0b 12. /build/src/IO/ReadBuffer.h:60: DB::ReadBuffer::next() @ 0x000000000a148c7b 13. /build/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) @ 0x0000000011849fb2 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]>&)>&, 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&) @ 0x0000000011841980 15. /build/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) @ 0x000000001621208e 16. /build/src/Storages/StorageReplicatedMergeTree.cpp:5228: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl[abi:se190107] const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000015f9a5fe 17. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000015ed8bfd 18. /build/src/Storages/StorageReplicatedMergeTree.cpp:2514: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x0000000015ec9aab 19. /build/src/Storages/StorageReplicatedMergeTree.cpp:2349: DB::StorageReplicatedMergeTree::executeLogEntry(DB::ReplicatedMergeTreeLogEntry&) @ 0x0000000015eba91b 20. /build/src/Storages/StorageReplicatedMergeTree.cpp:3876: bool std::__function::__policy_invoker&)>::__call_impl[abi:se190107])::$_1, bool (std::shared_ptr&)>>(std::__function::__policy_storage const*, std::shared_ptr&) @ 0x0000000015f9837e 21. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000165d6fc3 22. /build/src/Storages/StorageReplicatedMergeTree.cpp:3872: DB::StorageReplicatedMergeTree::processQueueEntry(std::shared_ptr) @ 0x0000000015efc18a 23. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001624c1b2 24. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000162f9c70 25. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x00000000162fa55a 26. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc6653 27. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000000fccc4c3 28. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc3d92 29. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fcca080 30. ? @ 0x00007fbc6213eac3 31. ? @ 0x00007fbc621d0850 (version 25.3.6.10636.altinitytest (altinity build)) 2025.07.28 11:56:31.471761 [ 3972 ] {} test_13.rmt2 (7f9b740d-015c-470e-8cc6-8ba33be0dc63): auto DB::StorageReplicatedMergeTree::processQueueEntry(ReplicatedMergeTreeQueue::SelectedEntryPtr)::(anonymous class)::operator()(LogEntryPtr &) const: Code: 86. DB::HTTPException: Received error from remote server http://146b4357c08d:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Ftest%2F01165%2Ftest_13%2Frmt%2Freplicas%2F1&part=20250728_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.6.10636.altinitytest (altinity build)) '. (RECEIVED_ERROR_FROM_REMOTE_IO_SERVER), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.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 const&, int&&, String const&, unsigned long&&, String const&) @ 0x000000000feda8d9 4. /build/src/IO/HTTPCommon.cpp:104: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x000000000feda6e2 5. /build/src/IO/HTTPCommon.cpp:93: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x000000000feda537 6. /build/src/IO/ReadWriteBufferFromHTTP.cpp:277: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x000000001184a4c4 7. /build/src/IO/ReadWriteBufferFromHTTP.cpp:285: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x000000001184a615 8. /build/src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x000000001184ae59 9. /build/src/IO/ReadWriteBufferFromHTTP.cpp:472: void std::__function::__policy_invoker::__call_impl[abi:se190107]>(std::__function::__policy_storage const*) @ 0x000000001184cedd 10. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001184858b 11. /build/src/IO/ReadWriteBufferFromHTTP.cpp:465: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x000000001184bf0b 12. /build/src/IO/ReadBuffer.h:60: DB::ReadBuffer::next() @ 0x000000000a148c7b 13. /build/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) @ 0x0000000011849fb2 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]>&)>&, 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&) @ 0x0000000011841980 15. /build/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) @ 0x000000001621208e 16. /build/src/Storages/StorageReplicatedMergeTree.cpp:5228: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl[abi:se190107] const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000015f9a5fe 17. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000015ed8bfd 18. /build/src/Storages/StorageReplicatedMergeTree.cpp:2514: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x0000000015ec9aab 19. /build/src/Storages/StorageReplicatedMergeTree.cpp:2349: DB::StorageReplicatedMergeTree::executeLogEntry(DB::ReplicatedMergeTreeLogEntry&) @ 0x0000000015eba91b 20. /build/src/Storages/StorageReplicatedMergeTree.cpp:3876: bool std::__function::__policy_invoker&)>::__call_impl[abi:se190107])::$_1, bool (std::shared_ptr&)>>(std::__function::__policy_storage const*, std::shared_ptr&) @ 0x0000000015f9837e 21. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000165d6fc3 22. /build/src/Storages/StorageReplicatedMergeTree.cpp:3872: DB::StorageReplicatedMergeTree::processQueueEntry(std::shared_ptr) @ 0x0000000015efc18a 23. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001624c1b2 24. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000162f9c70 25. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x00000000162fa55a 26. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc6653 27. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000000fccc4c3 28. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc3d92 29. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fcca080 30. ? @ 0x00007fbc6213eac3 31. ? @ 0x00007fbc621d0850 (version 25.3.6.10636.altinitytest (altinity build)) 2025.07.28 11:56:32.030565 [ 3968 ] {} test_13.rmt2 (7f9b740d-015c-470e-8cc6-8ba33be0dc63): auto DB::StorageReplicatedMergeTree::processQueueEntry(ReplicatedMergeTreeQueue::SelectedEntryPtr)::(anonymous class)::operator()(LogEntryPtr &) const: Code: 86. DB::HTTPException: Received error from remote server http://146b4357c08d:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Ftest%2F01165%2Ftest_13%2Frmt%2Freplicas%2F1&part=20250728_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.6.10636.altinitytest (altinity build)) '. (RECEIVED_ERROR_FROM_REMOTE_IO_SERVER), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.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 const&, int&&, String const&, unsigned long&&, String const&) @ 0x000000000feda8d9 4. /build/src/IO/HTTPCommon.cpp:104: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x000000000feda6e2 5. /build/src/IO/HTTPCommon.cpp:93: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x000000000feda537 6. /build/src/IO/ReadWriteBufferFromHTTP.cpp:277: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x000000001184a4c4 7. /build/src/IO/ReadWriteBufferFromHTTP.cpp:285: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x000000001184a615 8. /build/src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x000000001184ae59 9. /build/src/IO/ReadWriteBufferFromHTTP.cpp:472: void std::__function::__policy_invoker::__call_impl[abi:se190107]>(std::__function::__policy_storage const*) @ 0x000000001184cedd 10. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001184858b 11. /build/src/IO/ReadWriteBufferFromHTTP.cpp:465: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x000000001184bf0b 12. /build/src/IO/ReadBuffer.h:60: DB::ReadBuffer::next() @ 0x000000000a148c7b 13. /build/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) @ 0x0000000011849fb2 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]>&)>&, 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&) @ 0x0000000011841980 15. /build/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) @ 0x000000001621208e 16. /build/src/Storages/StorageReplicatedMergeTree.cpp:5228: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl[abi:se190107] const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000015f9a5fe 17. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000015ed8bfd 18. /build/src/Storages/StorageReplicatedMergeTree.cpp:2514: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x0000000015ec9aab 19. /build/src/Storages/StorageReplicatedMergeTree.cpp:2349: DB::StorageReplicatedMergeTree::executeLogEntry(DB::ReplicatedMergeTreeLogEntry&) @ 0x0000000015eba91b 20. /build/src/Storages/StorageReplicatedMergeTree.cpp:3876: bool std::__function::__policy_invoker&)>::__call_impl[abi:se190107])::$_1, bool (std::shared_ptr&)>>(std::__function::__policy_storage const*, std::shared_ptr&) @ 0x0000000015f9837e 21. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000165d6fc3 22. /build/src/Storages/StorageReplicatedMergeTree.cpp:3872: DB::StorageReplicatedMergeTree::processQueueEntry(std::shared_ptr) @ 0x0000000015efc18a 23. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001624c1b2 24. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000162f9c70 25. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x00000000162fa55a 26. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc6653 27. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000000fccc4c3 28. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc3d92 29. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fcca080 30. ? @ 0x00007fbc6213eac3 31. ? @ 0x00007fbc621d0850 (version 25.3.6.10636.altinitytest (altinity build)) 2025.07.28 11:56:32.909105 [ 3965 ] {} test_13.rmt2 (7f9b740d-015c-470e-8cc6-8ba33be0dc63): auto DB::StorageReplicatedMergeTree::processQueueEntry(ReplicatedMergeTreeQueue::SelectedEntryPtr)::(anonymous class)::operator()(LogEntryPtr &) const: Code: 86. DB::HTTPException: Received error from remote server http://146b4357c08d:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Ftest%2F01165%2Ftest_13%2Frmt%2Freplicas%2F1&part=20250728_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.6.10636.altinitytest (altinity build)) '. (RECEIVED_ERROR_FROM_REMOTE_IO_SERVER), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.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 const&, int&&, String const&, unsigned long&&, String const&) @ 0x000000000feda8d9 4. /build/src/IO/HTTPCommon.cpp:104: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x000000000feda6e2 5. /build/src/IO/HTTPCommon.cpp:93: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x000000000feda537 6. /build/src/IO/ReadWriteBufferFromHTTP.cpp:277: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x000000001184a4c4 7. /build/src/IO/ReadWriteBufferFromHTTP.cpp:285: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x000000001184a615 8. /build/src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x000000001184ae59 9. /build/src/IO/ReadWriteBufferFromHTTP.cpp:472: void std::__function::__policy_invoker::__call_impl[abi:se190107]>(std::__function::__policy_storage const*) @ 0x000000001184cedd 10. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001184858b 11. /build/src/IO/ReadWriteBufferFromHTTP.cpp:465: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x000000001184bf0b 12. /build/src/IO/ReadBuffer.h:60: DB::ReadBuffer::next() @ 0x000000000a148c7b 13. /build/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) @ 0x0000000011849fb2 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]>&)>&, 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&) @ 0x0000000011841980 15. /build/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) @ 0x000000001621208e 16. /build/src/Storages/StorageReplicatedMergeTree.cpp:5228: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl[abi:se190107] const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000015f9a5fe 17. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000015ed8bfd 18. /build/src/Storages/StorageReplicatedMergeTree.cpp:2514: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x0000000015ec9aab 19. /build/src/Storages/StorageReplicatedMergeTree.cpp:2349: DB::StorageReplicatedMergeTree::executeLogEntry(DB::ReplicatedMergeTreeLogEntry&) @ 0x0000000015eba91b 20. /build/src/Storages/StorageReplicatedMergeTree.cpp:3876: bool std::__function::__policy_invoker&)>::__call_impl[abi:se190107])::$_1, bool (std::shared_ptr&)>>(std::__function::__policy_storage const*, std::shared_ptr&) @ 0x0000000015f9837e 21. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000165d6fc3 22. /build/src/Storages/StorageReplicatedMergeTree.cpp:3872: DB::StorageReplicatedMergeTree::processQueueEntry(std::shared_ptr) @ 0x0000000015efc18a 23. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001624c1b2 24. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000162f9c70 25. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x00000000162fa55a 26. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc6653 27. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000000fccc4c3 28. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc3d92 29. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fcca080 30. ? @ 0x00007fbc6213eac3 31. ? @ 0x00007fbc621d0850 (version 25.3.6.10636.altinitytest (altinity build)) 2025.07.28 11:56:33.180011 [ 5825 ] {0124d4dc-7702-4ae9-8539-c22b1745b0ed} executeQuery: Code: 344. DB::Exception: DELETE query is not allowed for table test_voiat7g4.users_wide because as it has projections and setting lightweight_mutation_projection_mode is set to THROW. User should change lightweight_mutation_projection_mode OR drop all the projections manually before running the query. (SUPPORT_IS_DISABLED) (version 25.3.6.10636.altinitytest (altinity build)) (from [::1]:46646) (comment: 03161_lightweight_delete_projection.sql) (query 30, line 97) (in query: DELETE FROM users_wide WHERE uid = 1231;), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x000000000a06b56b 4. /build/src/Interpreters/InterpreterDeleteQuery.cpp:113: DB::InterpreterDeleteQuery::execute() @ 0x0000000014d00fc3 5. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88dc9 6. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 7. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 8. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 9. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 10. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 11. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 12. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 13. ? @ 0x00007fbc6213eac3 14. ? @ 0x00007fbc621d0850 2025.07.28 11:56:33.187434 [ 5825 ] {} TCPHandler: Code: 344. DB::Exception: DELETE query is not allowed for table test_voiat7g4.users_wide because as it has projections and setting lightweight_mutation_projection_mode is set to THROW. User should change lightweight_mutation_projection_mode OR drop all the projections manually before running the query. (SUPPORT_IS_DISABLED), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x000000000a06b56b 4. /build/src/Interpreters/InterpreterDeleteQuery.cpp:113: DB::InterpreterDeleteQuery::execute() @ 0x0000000014d00fc3 5. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88dc9 6. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 7. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 8. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 9. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 10. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 11. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 12. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 13. ? @ 0x00007fbc6213eac3 14. ? @ 0x00007fbc621d0850 2025.07.28 11:56:33.416010 [ 3970 ] {} test_13.rmt2 (7f9b740d-015c-470e-8cc6-8ba33be0dc63): auto DB::StorageReplicatedMergeTree::processQueueEntry(ReplicatedMergeTreeQueue::SelectedEntryPtr)::(anonymous class)::operator()(LogEntryPtr &) const: Code: 86. DB::HTTPException: Received error from remote server http://146b4357c08d:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Ftest%2F01165%2Ftest_13%2Frmt%2Freplicas%2F1&part=20250728_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.6.10636.altinitytest (altinity build)) '. (RECEIVED_ERROR_FROM_REMOTE_IO_SERVER), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.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 const&, int&&, String const&, unsigned long&&, String const&) @ 0x000000000feda8d9 4. /build/src/IO/HTTPCommon.cpp:104: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x000000000feda6e2 5. /build/src/IO/HTTPCommon.cpp:93: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x000000000feda537 6. /build/src/IO/ReadWriteBufferFromHTTP.cpp:277: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x000000001184a4c4 7. /build/src/IO/ReadWriteBufferFromHTTP.cpp:285: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x000000001184a615 8. /build/src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x000000001184ae59 9. /build/src/IO/ReadWriteBufferFromHTTP.cpp:472: void std::__function::__policy_invoker::__call_impl[abi:se190107]>(std::__function::__policy_storage const*) @ 0x000000001184cedd 10. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001184858b 11. /build/src/IO/ReadWriteBufferFromHTTP.cpp:465: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x000000001184bf0b 12. /build/src/IO/ReadBuffer.h:60: DB::ReadBuffer::next() @ 0x000000000a148c7b 13. /build/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) @ 0x0000000011849fb2 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]>&)>&, 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&) @ 0x0000000011841980 15. /build/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) @ 0x000000001621208e 16. /build/src/Storages/StorageReplicatedMergeTree.cpp:5228: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl[abi:se190107] const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000015f9a5fe 17. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000015ed8bfd 18. /build/src/Storages/StorageReplicatedMergeTree.cpp:2514: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x0000000015ec9aab 19. /build/src/Storages/StorageReplicatedMergeTree.cpp:2349: DB::StorageReplicatedMergeTree::executeLogEntry(DB::ReplicatedMergeTreeLogEntry&) @ 0x0000000015eba91b 20. /build/src/Storages/StorageReplicatedMergeTree.cpp:3876: bool std::__function::__policy_invoker&)>::__call_impl[abi:se190107])::$_1, bool (std::shared_ptr&)>>(std::__function::__policy_storage const*, std::shared_ptr&) @ 0x0000000015f9837e 21. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000165d6fc3 22. /build/src/Storages/StorageReplicatedMergeTree.cpp:3872: DB::StorageReplicatedMergeTree::processQueueEntry(std::shared_ptr) @ 0x0000000015efc18a 23. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001624c1b2 24. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000162f9c70 25. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x00000000162fa55a 26. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc6653 27. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000000fccc4c3 28. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc3d92 29. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fcca080 30. ? @ 0x00007fbc6213eac3 31. ? @ 0x00007fbc621d0850 (version 25.3.6.10636.altinitytest (altinity build)) 2025.07.28 11:56:33.438279 [ 3287 ] {fdade8f5-f1d8-4a8c-94f3-f61185bca78c} executeQuery: Code: 241. DB::Exception: Query memory limit exceeded: would use 1.02 GiB (attempt to allocate chunk of 128.00 MiB bytes), maximum: 953.67 MiB.: While executing AggregatingTransform. (MEMORY_LIMIT_EXCEEDED) (version 25.3.6.10636.altinitytest (altinity build)) (from [::ffff:127.0.0.1]:57532) (comment: 01514_distributed_cancel_query_on_error.sh) (query 1, line 1) (in query: SELECT groupArray(repeat('a', if(shardNum() = 2, 100000, 1))) AS `groupArray(repeat('a', if(equals(_shard_num, 2), 100000, 1)))`, `__table1`.`number` % 100000 AS `k` FROM `system`.`numbers` AS `__table1` GROUP BY `__table1`.`number` % 100000 LIMIT _CAST(10000000, 'UInt64')), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000000fc1ab36 4. /build/src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000000fc196ef 5. /build/src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000000fc19293 6. /build/src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000000fb80c54 7. /build/src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000000fb7f3c4 8. /build/src/Common/Arena.h:76: DB::Arena::addMemoryChunk(unsigned long) @ 0x000000000aabf255 9. /build/src/Common/Arena.h:196: DB::(anonymous namespace)::GroupArrayNodeString::allocate(DB::IColumn const&, unsigned long, DB::Arena*) @ 0x000000001018a2ff 10. /build/src/AggregateFunctions/AggregateFunctionGroupArray.cpp:554: DB::IAggregateFunctionHelper>>::addBatch(unsigned long, unsigned long, char**, unsigned long, DB::IColumn const**, DB::Arena*, long) const @ 0x00000000101aecb5 11. /build/src/Interpreters/Aggregator.cpp:1338: DB::Aggregator::executeAggregateInstructions(DB::Arena*, unsigned long, unsigned long, DB::Aggregator::AggregateFunctionInstruction*, std::unique_ptr> const&, unsigned long, bool, bool, bool) const @ 0x0000000014591614 12. /build/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 @ 0x00000000146bf12d 13. /build/src/Interpreters/Aggregator.cpp:0: 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 @ 0x00000000146bc9c2 14. /build/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 @ 0x00000000145fd7cf 15. /build/src/Interpreters/Aggregator.cpp:922: DB::Aggregator::executeImpl(DB::AggregatedDataVariants&, unsigned long, unsigned long, std::vector>&, DB::Aggregator::AggregateFunctionInstruction*, bool, bool, char*) const @ 0x000000001458fd39 16. /build/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 @ 0x0000000014593b80 17. /build/src/Processors/Transforms/AggregatingTransform.cpp:690: DB::AggregatingTransform::consume(DB::Chunk) @ 0x0000000016bf205c 18. /build/src/Processors/Transforms/AggregatingTransform.cpp:648: DB::AggregatingTransform::work() @ 0x0000000016bef6c6 19. /build/src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x00000000169bd00f 20. /build/src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x00000000169b2105 21. /build/src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeSingleThread(unsigned long) @ 0x00000000169b23be 22. /build/src/Processors/Executors/PipelineExecutor.cpp:454: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x00000000169b0be7 23. /build/src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x00000000169b03f4 24. /build/src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:se190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169bfeab 25. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc3d92 26. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fcca080 27. ? @ 0x00007fbc6213eac3 28. ? @ 0x00007fbc621d0850 2025.07.28 11:56:33.452002 [ 3287 ] {} TCPHandler: Code: 241. DB::Exception: Query memory limit exceeded: would use 1.02 GiB (attempt to allocate chunk of 128.00 MiB bytes), maximum: 953.67 MiB.: While executing AggregatingTransform. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000000fc1ab36 4. /build/src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000000fc196ef 5. /build/src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000000fc19293 6. /build/src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000000fb80c54 7. /build/src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000000fb7f3c4 8. /build/src/Common/Arena.h:76: DB::Arena::addMemoryChunk(unsigned long) @ 0x000000000aabf255 9. /build/src/Common/Arena.h:196: DB::(anonymous namespace)::GroupArrayNodeString::allocate(DB::IColumn const&, unsigned long, DB::Arena*) @ 0x000000001018a2ff 10. /build/src/AggregateFunctions/AggregateFunctionGroupArray.cpp:554: DB::IAggregateFunctionHelper>>::addBatch(unsigned long, unsigned long, char**, unsigned long, DB::IColumn const**, DB::Arena*, long) const @ 0x00000000101aecb5 11. /build/src/Interpreters/Aggregator.cpp:1338: DB::Aggregator::executeAggregateInstructions(DB::Arena*, unsigned long, unsigned long, DB::Aggregator::AggregateFunctionInstruction*, std::unique_ptr> const&, unsigned long, bool, bool, bool) const @ 0x0000000014591614 12. /build/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 @ 0x00000000146bf12d 13. /build/src/Interpreters/Aggregator.cpp:0: 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 @ 0x00000000146bc9c2 14. /build/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 @ 0x00000000145fd7cf 15. /build/src/Interpreters/Aggregator.cpp:922: DB::Aggregator::executeImpl(DB::AggregatedDataVariants&, unsigned long, unsigned long, std::vector>&, DB::Aggregator::AggregateFunctionInstruction*, bool, bool, char*) const @ 0x000000001458fd39 16. /build/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 @ 0x0000000014593b80 17. /build/src/Processors/Transforms/AggregatingTransform.cpp:690: DB::AggregatingTransform::consume(DB::Chunk) @ 0x0000000016bf205c 18. /build/src/Processors/Transforms/AggregatingTransform.cpp:648: DB::AggregatingTransform::work() @ 0x0000000016bef6c6 19. /build/src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x00000000169bd00f 20. /build/src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x00000000169b2105 21. /build/src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeSingleThread(unsigned long) @ 0x00000000169b23be 22. /build/src/Processors/Executors/PipelineExecutor.cpp:454: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x00000000169b0be7 23. /build/src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x00000000169b03f4 24. /build/src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:se190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169bfeab 25. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc3d92 26. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fcca080 27. ? @ 0x00007fbc6213eac3 28. ? @ 0x00007fbc621d0850 Job's origin stack trace: 0. /build/src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000000fc33b84 1. /build/src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000000fcc2ea7 2. /build/src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fcc535c 3. /build/src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000000fcc584d 4. /build/src/Common/ThreadPool.h:279: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x00000000169bf193 5. /build/src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x00000000169bf518 6. /build/src/Server/TCPHandler.cpp:1237: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x00000000168f1525 7. /build/src/Server/TCPHandler.cpp:678: DB::TCPHandler::runImpl() @ 0x00000000168e68e5 8. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 9. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 10. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 11. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 12. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 13. ? @ 0x00007fbc6213eac3 14. ? @ 0x00007fbc621d0850 2025.07.28 11:56:33.486412 [ 5879 ] {deae0cd8-5452-437f-87e1-c9e50d2ed35e} executeQuery: Code: 241. DB::Exception: Received from 127.3:9000. DB::Exception: Query memory limit exceeded: would use 1.02 GiB (attempt to allocate chunk of 128.00 MiB bytes), maximum: 953.67 MiB.: While executing AggregatingTransform. Stack trace: 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000000fc1ab36 4. /build/src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000000fc196ef 5. /build/src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000000fc19293 6. /build/src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000000fb80c54 7. /build/src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000000fb7f3c4 8. /build/src/Common/Arena.h:76: DB::Arena::addMemoryChunk(unsigned long) @ 0x000000000aabf255 9. /build/src/Common/Arena.h:196: DB::(anonymous namespace)::GroupArrayNodeString::allocate(DB::IColumn const&, unsigned long, DB::Arena*) @ 0x000000001018a2ff 10. /build/src/AggregateFunctions/AggregateFunctionGroupArray.cpp:554: DB::IAggregateFunctionHelper>>::addBatch(unsigned long, unsigned long, char**, unsigned long, DB::IColumn const**, DB::Arena*, long) const @ 0x00000000101aecb5 11. /build/src/Interpreters/Aggregator.cpp:1338: DB::Aggregator::executeAggregateInstructions(DB::Arena*, unsigned long, unsigned long, DB::Aggregator::AggregateFunctionInstruction*, std::unique_ptr> const&, unsigned long, bool, bool, bool) const @ 0x0000000014591614 12. /build/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 @ 0x00000000146bf12d 13. /build/src/Interpreters/Aggregator.cpp:0: 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 @ 0x00000000146bc9c2 14. /build/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 @ 0x00000000145fd7cf 15. /build/src/Interpreters/Aggregator.cpp:922: DB::Aggregator::executeImpl(DB::AggregatedDataVariants&, unsigned long, unsigned long, std::vector>&, DB::Aggregator::AggregateFunctionInstruction*, bool, bool, char*) const @ 0x000000001458fd39 16. /build/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 @ 0x0000000014593b80 17. /build/src/Processors/Transforms/AggregatingTransform.cpp:690: DB::AggregatingTransform::consume(DB::Chunk) @ 0x0000000016bf205c 18. /build/src/Processors/Transforms/AggregatingTransform.cpp:648: DB::AggregatingTransform::work() @ 0x0000000016bef6c6 19. /build/src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x00000000169bd00f 20. /build/src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x00000000169b2105 21. /build/src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeSingleThread(unsigned long) @ 0x00000000169b23be 22. /build/src/Processors/Executors/PipelineExecutor.cpp:454: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x00000000169b0be7 23. /build/src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x00000000169b03f4 24. /build/src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:se190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169bfeab 25. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc3d92 26. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fcca080 27. ? @ 0x00007fbc6213eac3 28. ? @ 0x00007fbc621d0850 Job's origin stack trace: 0. /build/src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000000fc33b84 1. /build/src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000000fcc2ea7 2. /build/src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fcc535c 3. /build/src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000000fcc584d 4. /build/src/Common/ThreadPool.h:279: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x00000000169bf193 5. /build/src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x00000000169bf518 6. /build/src/Server/TCPHandler.cpp:1237: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x00000000168f1525 7. /build/src/Server/TCPHandler.cpp:678: DB::TCPHandler::runImpl() @ 0x00000000168e68e5 8. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 9. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 10. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 11. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 12. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 13. ? @ 0x00007fbc6213eac3 14. ? @ 0x00007fbc621d0850 : While executing Remote. (MEMORY_LIMIT_EXCEEDED) (version 25.3.6.10636.altinitytest (altinity build)) (from [::1]:37482) (comment: 01514_distributed_cancel_query_on_error.sh) (query 1, line 1) (in query: SELECT groupArray(repeat('a', if(_shard_num == 2, 100000, 1))), number%100000 k from remote('127.{2,3}', system.numbers) GROUP BY k LIMIT 10e6), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:111: DB::readException(DB::ReadBuffer&, String const&, bool) @ 0x000000000fc6e157 3. /build/src/Client/Connection.cpp:1445: DB::Connection::receiveException() const @ 0x00000000167d4127 4. /build/src/Client/Connection.cpp:1274: DB::Connection::receivePacket() @ 0x00000000167db312 5. /build/src/Client/PacketReceiver.cpp:66: DB::PacketReceiver::Task::run(std::function, std::function) @ 0x0000000016819393 6. /build/src/Common/AsyncTaskExecutor.cpp:89: DB::AsyncTaskExecutor::Routine::operator()(std::function) @ 0x0000000013bd1892 7. /build/src/Common/Fiber.h:76: boost::context::detail::fiber_record>::run(void*) @ 0x0000000013bd16fa 8. /build/contrib/boost/boost/context/fiber_fcontext.hpp:97: void boost::context::detail::fiber_entry>>(boost::context::detail::transfer_t) @ 0x0000000013bd1621 2025.07.28 11:56:33.504523 [ 5879 ] {} TCPHandler: Code: 241. DB::Exception: Received from 127.3:9000. DB::Exception: Query memory limit exceeded: would use 1.02 GiB (attempt to allocate chunk of 128.00 MiB bytes), maximum: 953.67 MiB.: While executing AggregatingTransform. Stack trace: 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000000fc1ab36 4. /build/src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000000fc196ef 5. /build/src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000000fc19293 6. /build/src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000000fb80c54 7. /build/src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000000fb7f3c4 8. /build/src/Common/Arena.h:76: DB::Arena::addMemoryChunk(unsigned long) @ 0x000000000aabf255 9. /build/src/Common/Arena.h:196: DB::(anonymous namespace)::GroupArrayNodeString::allocate(DB::IColumn const&, unsigned long, DB::Arena*) @ 0x000000001018a2ff 10. /build/src/AggregateFunctions/AggregateFunctionGroupArray.cpp:554: DB::IAggregateFunctionHelper>>::addBatch(unsigned long, unsigned long, char**, unsigned long, DB::IColumn const**, DB::Arena*, long) const @ 0x00000000101aecb5 11. /build/src/Interpreters/Aggregator.cpp:1338: DB::Aggregator::executeAggregateInstructions(DB::Arena*, unsigned long, unsigned long, DB::Aggregator::AggregateFunctionInstruction*, std::unique_ptr> const&, unsigned long, bool, bool, bool) const @ 0x0000000014591614 12. /build/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 @ 0x00000000146bf12d 13. /build/src/Interpreters/Aggregator.cpp:0: 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 @ 0x00000000146bc9c2 14. /build/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 @ 0x00000000145fd7cf 15. /build/src/Interpreters/Aggregator.cpp:922: DB::Aggregator::executeImpl(DB::AggregatedDataVariants&, unsigned long, unsigned long, std::vector>&, DB::Aggregator::AggregateFunctionInstruction*, bool, bool, char*) const @ 0x000000001458fd39 16. /build/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 @ 0x0000000014593b80 17. /build/src/Processors/Transforms/AggregatingTransform.cpp:690: DB::AggregatingTransform::consume(DB::Chunk) @ 0x0000000016bf205c 18. /build/src/Processors/Transforms/AggregatingTransform.cpp:648: DB::AggregatingTransform::work() @ 0x0000000016bef6c6 19. /build/src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x00000000169bd00f 20. /build/src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x00000000169b2105 21. /build/src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeSingleThread(unsigned long) @ 0x00000000169b23be 22. /build/src/Processors/Executors/PipelineExecutor.cpp:454: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x00000000169b0be7 23. /build/src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x00000000169b03f4 24. /build/src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:se190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169bfeab 25. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc3d92 26. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fcca080 27. ? @ 0x00007fbc6213eac3 28. ? @ 0x00007fbc621d0850 Job's origin stack trace: 0. /build/src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000000fc33b84 1. /build/src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000000fcc2ea7 2. /build/src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fcc535c 3. /build/src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000000fcc584d 4. /build/src/Common/ThreadPool.h:279: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x00000000169bf193 5. /build/src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x00000000169bf518 6. /build/src/Server/TCPHandler.cpp:1237: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x00000000168f1525 7. /build/src/Server/TCPHandler.cpp:678: DB::TCPHandler::runImpl() @ 0x00000000168e68e5 8. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 9. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 10. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 11. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 12. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 13. ? @ 0x00007fbc6213eac3 14. ? @ 0x00007fbc621d0850 : While executing Remote. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:111: DB::readException(DB::ReadBuffer&, String const&, bool) @ 0x000000000fc6e157 3. /build/src/Client/Connection.cpp:1445: DB::Connection::receiveException() const @ 0x00000000167d4127 4. /build/src/Client/Connection.cpp:1274: DB::Connection::receivePacket() @ 0x00000000167db312 5. /build/src/Client/PacketReceiver.cpp:66: DB::PacketReceiver::Task::run(std::function, std::function) @ 0x0000000016819393 6. /build/src/Common/AsyncTaskExecutor.cpp:89: DB::AsyncTaskExecutor::Routine::operator()(std::function) @ 0x0000000013bd1892 7. /build/src/Common/Fiber.h:76: boost::context::detail::fiber_record>::run(void*) @ 0x0000000013bd16fa 8. /build/contrib/boost/boost/context/fiber_fcontext.hpp:97: void boost::context::detail::fiber_entry>>(boost::context::detail::transfer_t) @ 0x0000000013bd1621 Job's origin stack trace: 0. /build/src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000000fc33b84 1. /build/src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000000fcc2ea7 2. /build/src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fcc535c 3. /build/src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000000fcc584d 4. /build/src/Common/ThreadPool.h:279: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x00000000169bf193 5. /build/src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x00000000169bf518 6. /build/src/Server/TCPHandler.cpp:1237: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x00000000168f1525 7. /build/src/Server/TCPHandler.cpp:678: DB::TCPHandler::runImpl() @ 0x00000000168e68e5 8. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 9. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 10. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 11. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 12. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 13. ? @ 0x00007fbc6213eac3 14. ? @ 0x00007fbc621d0850 2025.07.28 11:56:33.684323 [ 17208 ] {7154d5ec-e42f-4332-8edb-e36295548c19} 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]:49998). (NETWORK_ERROR), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::NetException::NetException(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&) @ 0x000000000fd50fb5 3. /build/src/IO/WriteBufferFromPocoSocket.cpp:160: DB::WriteBufferFromPocoSocket::nextImpl() @ 0x000000000fd523f1 4. /build/src/IO/WriteBuffer.h:53: DB::WriteBuffer::next() @ 0x000000000a0755be 5. /build/src/Server/TCPHandler.cpp:824: DB::TCPHandler::runImpl() @ 0x00000000168e6c86 6. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 7. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 8. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 9. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 10. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 11. ? @ 0x00007fbc6213eac3 12. ? @ 0x00007fbc621d0850 (version 25.3.6.10636.altinitytest (altinity build)) 2025.07.28 11:56:34.357630 [ 3960 ] {} test_13.rmt2 (7f9b740d-015c-470e-8cc6-8ba33be0dc63): auto DB::StorageReplicatedMergeTree::processQueueEntry(ReplicatedMergeTreeQueue::SelectedEntryPtr)::(anonymous class)::operator()(LogEntryPtr &) const: Code: 86. DB::HTTPException: Received error from remote server http://146b4357c08d:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Ftest%2F01165%2Ftest_13%2Frmt%2Freplicas%2F1&part=20250728_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.6.10636.altinitytest (altinity build)) '. (RECEIVED_ERROR_FROM_REMOTE_IO_SERVER), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.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 const&, int&&, String const&, unsigned long&&, String const&) @ 0x000000000feda8d9 4. /build/src/IO/HTTPCommon.cpp:104: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x000000000feda6e2 5. /build/src/IO/HTTPCommon.cpp:93: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x000000000feda537 6. /build/src/IO/ReadWriteBufferFromHTTP.cpp:277: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x000000001184a4c4 7. /build/src/IO/ReadWriteBufferFromHTTP.cpp:285: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x000000001184a615 8. /build/src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x000000001184ae59 9. /build/src/IO/ReadWriteBufferFromHTTP.cpp:472: void std::__function::__policy_invoker::__call_impl[abi:se190107]>(std::__function::__policy_storage const*) @ 0x000000001184cedd 10. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001184858b 11. /build/src/IO/ReadWriteBufferFromHTTP.cpp:465: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x000000001184bf0b 12. /build/src/IO/ReadBuffer.h:60: DB::ReadBuffer::next() @ 0x000000000a148c7b 13. /build/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) @ 0x0000000011849fb2 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]>&)>&, 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&) @ 0x0000000011841980 15. /build/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) @ 0x000000001621208e 16. /build/src/Storages/StorageReplicatedMergeTree.cpp:5228: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl[abi:se190107] const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000015f9a5fe 17. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000015ed8bfd 18. /build/src/Storages/StorageReplicatedMergeTree.cpp:2514: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x0000000015ec9aab 19. /build/src/Storages/StorageReplicatedMergeTree.cpp:2349: DB::StorageReplicatedMergeTree::executeLogEntry(DB::ReplicatedMergeTreeLogEntry&) @ 0x0000000015eba91b 20. /build/src/Storages/StorageReplicatedMergeTree.cpp:3876: bool std::__function::__policy_invoker&)>::__call_impl[abi:se190107])::$_1, bool (std::shared_ptr&)>>(std::__function::__policy_storage const*, std::shared_ptr&) @ 0x0000000015f9837e 21. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000165d6fc3 22. /build/src/Storages/StorageReplicatedMergeTree.cpp:3872: DB::StorageReplicatedMergeTree::processQueueEntry(std::shared_ptr) @ 0x0000000015efc18a 23. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001624c1b2 24. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000162f9c70 25. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x00000000162fa55a 26. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc6653 27. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000000fccc4c3 28. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc3d92 29. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fcca080 30. ? @ 0x00007fbc6213eac3 31. ? @ 0x00007fbc621d0850 (version 25.3.6.10636.altinitytest (altinity build)) 2025.07.28 11:56:34.703627 [ 3964 ] {} test_13.rmt2 (7f9b740d-015c-470e-8cc6-8ba33be0dc63): auto DB::StorageReplicatedMergeTree::processQueueEntry(ReplicatedMergeTreeQueue::SelectedEntryPtr)::(anonymous class)::operator()(LogEntryPtr &) const: Code: 86. DB::HTTPException: Received error from remote server http://146b4357c08d:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Ftest%2F01165%2Ftest_13%2Frmt%2Freplicas%2F1&part=20250728_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.6.10636.altinitytest (altinity build)) '. (RECEIVED_ERROR_FROM_REMOTE_IO_SERVER), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.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 const&, int&&, String const&, unsigned long&&, String const&) @ 0x000000000feda8d9 4. /build/src/IO/HTTPCommon.cpp:104: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x000000000feda6e2 5. /build/src/IO/HTTPCommon.cpp:93: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x000000000feda537 6. /build/src/IO/ReadWriteBufferFromHTTP.cpp:277: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x000000001184a4c4 7. /build/src/IO/ReadWriteBufferFromHTTP.cpp:285: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x000000001184a615 8. /build/src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x000000001184ae59 9. /build/src/IO/ReadWriteBufferFromHTTP.cpp:472: void std::__function::__policy_invoker::__call_impl[abi:se190107]>(std::__function::__policy_storage const*) @ 0x000000001184cedd 10. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001184858b 11. /build/src/IO/ReadWriteBufferFromHTTP.cpp:465: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x000000001184bf0b 12. /build/src/IO/ReadBuffer.h:60: DB::ReadBuffer::next() @ 0x000000000a148c7b 13. /build/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) @ 0x0000000011849fb2 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]>&)>&, 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&) @ 0x0000000011841980 15. /build/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) @ 0x000000001621208e 16. /build/src/Storages/StorageReplicatedMergeTree.cpp:5228: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl[abi:se190107] const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000015f9a5fe 17. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000015ed8bfd 18. /build/src/Storages/StorageReplicatedMergeTree.cpp:2514: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x0000000015ec9aab 19. /build/src/Storages/StorageReplicatedMergeTree.cpp:2349: DB::StorageReplicatedMergeTree::executeLogEntry(DB::ReplicatedMergeTreeLogEntry&) @ 0x0000000015eba91b 20. /build/src/Storages/StorageReplicatedMergeTree.cpp:3876: bool std::__function::__policy_invoker&)>::__call_impl[abi:se190107])::$_1, bool (std::shared_ptr&)>>(std::__function::__policy_storage const*, std::shared_ptr&) @ 0x0000000015f9837e 21. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000165d6fc3 22. /build/src/Storages/StorageReplicatedMergeTree.cpp:3872: DB::StorageReplicatedMergeTree::processQueueEntry(std::shared_ptr) @ 0x0000000015efc18a 23. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001624c1b2 24. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000162f9c70 25. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x00000000162fa55a 26. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc6653 27. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000000fccc4c3 28. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc3d92 29. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fcca080 30. ? @ 0x00007fbc6213eac3 31. ? @ 0x00007fbc621d0850 (version 25.3.6.10636.altinitytest (altinity build)) 2025.07.28 11:56:35.305770 [ 3966 ] {} test_13.rmt2 (7f9b740d-015c-470e-8cc6-8ba33be0dc63): auto DB::StorageReplicatedMergeTree::processQueueEntry(ReplicatedMergeTreeQueue::SelectedEntryPtr)::(anonymous class)::operator()(LogEntryPtr &) const: Code: 86. DB::HTTPException: Received error from remote server http://146b4357c08d:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Ftest%2F01165%2Ftest_13%2Frmt%2Freplicas%2F1&part=20250728_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.6.10636.altinitytest (altinity build)) '. (RECEIVED_ERROR_FROM_REMOTE_IO_SERVER), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.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 const&, int&&, String const&, unsigned long&&, String const&) @ 0x000000000feda8d9 4. /build/src/IO/HTTPCommon.cpp:104: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x000000000feda6e2 5. /build/src/IO/HTTPCommon.cpp:93: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x000000000feda537 6. /build/src/IO/ReadWriteBufferFromHTTP.cpp:277: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x000000001184a4c4 7. /build/src/IO/ReadWriteBufferFromHTTP.cpp:285: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x000000001184a615 8. /build/src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x000000001184ae59 9. /build/src/IO/ReadWriteBufferFromHTTP.cpp:472: void std::__function::__policy_invoker::__call_impl[abi:se190107]>(std::__function::__policy_storage const*) @ 0x000000001184cedd 10. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001184858b 11. /build/src/IO/ReadWriteBufferFromHTTP.cpp:465: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x000000001184bf0b 12. /build/src/IO/ReadBuffer.h:60: DB::ReadBuffer::next() @ 0x000000000a148c7b 13. /build/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) @ 0x0000000011849fb2 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]>&)>&, 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&) @ 0x0000000011841980 15. /build/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) @ 0x000000001621208e 16. /build/src/Storages/StorageReplicatedMergeTree.cpp:5228: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl[abi:se190107] const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000015f9a5fe 17. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000015ed8bfd 18. /build/src/Storages/StorageReplicatedMergeTree.cpp:2514: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x0000000015ec9aab 19. /build/src/Storages/StorageReplicatedMergeTree.cpp:2349: DB::StorageReplicatedMergeTree::executeLogEntry(DB::ReplicatedMergeTreeLogEntry&) @ 0x0000000015eba91b 20. /build/src/Storages/StorageReplicatedMergeTree.cpp:3876: bool std::__function::__policy_invoker&)>::__call_impl[abi:se190107])::$_1, bool (std::shared_ptr&)>>(std::__function::__policy_storage const*, std::shared_ptr&) @ 0x0000000015f9837e 21. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000165d6fc3 22. /build/src/Storages/StorageReplicatedMergeTree.cpp:3872: DB::StorageReplicatedMergeTree::processQueueEntry(std::shared_ptr) @ 0x0000000015efc18a 23. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001624c1b2 24. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000162f9c70 25. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x00000000162fa55a 26. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc6653 27. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000000fccc4c3 28. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc3d92 29. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fcca080 30. ? @ 0x00007fbc6213eac3 31. ? @ 0x00007fbc621d0850 (version 25.3.6.10636.altinitytest (altinity build)) 2025.07.28 11:56:35.973387 [ 17321 ] {587eda57-ec2a-4c39-9bf9-3b8456d67ad1} executeQuery: Code: 306. DB::Exception: Maximum parse depth (1000) exceeded. Consider rising max_parser_depth parameter. (TOO_DEEP_RECURSION) (version 25.3.6.10636.altinitytest (altinity build)) (from [::ffff:127.0.0.1]:55462) (comment: 00984_parser_stack_overflow.sh) (in query: ((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((((), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type>, unsigned int&) @ 0x000000000de86fcb 4. /build/src/Parsers/IParser.h:114: DB::IParserBase::parse(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x0000000017a36e93 5. /build/src/Parsers/ExpressionListParsers.cpp:82: DB::ParserUnionList::parseImpl(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&)::$_0::operator()() const @ 0x0000000017a23244 6. /build/src/Parsers/ExpressionListParsers.h:89: DB::ParserUnionList::parseImpl(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x0000000017a1ab73 7. /build/src/Parsers/IParserBase.cpp:14: DB::IParserBase::parse(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x0000000017a36cf0 8. /build/src/Parsers/ParserSelectWithUnionQuery.cpp:15: DB::ParserSelectWithUnionQuery::parseImpl(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x0000000017a73745 9. /build/src/Parsers/IParserBase.cpp:14: DB::IParserBase::parse(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x0000000017a36cf0 10. /build/src/Parsers/ExpressionElementParsers.cpp:116: DB::ParserSubquery::parseImpl(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x0000000017a05f3a 11. /build/src/Parsers/IParserBase.cpp:14: DB::IParserBase::parse(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x0000000017a36cf0 12. /build/src/Parsers/ParserUnionQueryElement.cpp:13: DB::ParserUnionQueryElement::parseImpl(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x0000000017a8a1ef 13. /build/src/Parsers/IParserBase.cpp:14: DB::IParserBase::parse(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x0000000017a36cf0 14. /build/src/Parsers/ExpressionListParsers.cpp:82: DB::ParserUnionList::parseImpl(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&)::$_0::operator()() const @ 0x0000000017a23244 15. /build/src/Parsers/ExpressionListParsers.h:89: DB::ParserUnionList::parseImpl(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x0000000017a1ab73 16. /build/src/Parsers/IParserBase.cpp:14: DB::IParserBase::parse(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x0000000017a36cf0 17. /build/src/Parsers/ParserSelectWithUnionQuery.cpp:15: DB::ParserSelectWithUnionQuery::parseImpl(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x0000000017a73745 18. /build/src/Parsers/IParserBase.cpp:14: DB::IParserBase::parse(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x0000000017a36cf0 19. /build/src/Parsers/ExpressionElementParsers.cpp:116: DB::ParserSubquery::parseImpl(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x0000000017a05f3a 20. /build/src/Parsers/IParserBase.cpp:14: DB::IParserBase::parse(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x0000000017a36cf0 21. /build/src/Parsers/ParserUnionQueryElement.cpp:13: DB::ParserUnionQueryElement::parseImpl(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x0000000017a8a1ef 22. /build/src/Parsers/IParserBase.cpp:14: DB::IParserBase::parse(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x0000000017a36cf0 23. /build/src/Parsers/ExpressionListParsers.cpp:82: DB::ParserUnionList::parseImpl(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&)::$_0::operator()() const @ 0x0000000017a23244 24. /build/src/Parsers/ExpressionListParsers.h:89: DB::ParserUnionList::parseImpl(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x0000000017a1ab73 25. /build/src/Parsers/IParserBase.cpp:14: DB::IParserBase::parse(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x0000000017a36cf0 26. /build/src/Parsers/ParserSelectWithUnionQuery.cpp:15: DB::ParserSelectWithUnionQuery::parseImpl(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x0000000017a73745 27. /build/src/Parsers/IParserBase.cpp:14: DB::IParserBase::parse(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x0000000017a36cf0 28. /build/src/Parsers/ExpressionElementParsers.cpp:116: DB::ParserSubquery::parseImpl(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x0000000017a05f3a 29. /build/src/Parsers/IParserBase.cpp:14: DB::IParserBase::parse(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x0000000017a36cf0 30. /build/src/Parsers/ParserUnionQueryElement.cpp:13: DB::ParserUnionQueryElement::parseImpl(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x0000000017a8a1ef 31. /build/src/Parsers/IParserBase.cpp:14: DB::IParserBase::parse(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x0000000017a36cf0 2025.07.28 11:56:35.977000 [ 17321 ] {587eda57-ec2a-4c39-9bf9-3b8456d67ad1} DynamicQueryHandler: Code: 306. DB::Exception: Maximum parse depth (1000) exceeded. Consider rising max_parser_depth parameter. (TOO_DEEP_RECURSION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type>, unsigned int&) @ 0x000000000de86fcb 4. /build/src/Parsers/IParser.h:114: DB::IParserBase::parse(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x0000000017a36e93 5. /build/src/Parsers/ExpressionListParsers.cpp:82: DB::ParserUnionList::parseImpl(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&)::$_0::operator()() const @ 0x0000000017a23244 6. /build/src/Parsers/ExpressionListParsers.h:89: DB::ParserUnionList::parseImpl(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x0000000017a1ab73 7. /build/src/Parsers/IParserBase.cpp:14: DB::IParserBase::parse(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x0000000017a36cf0 8. /build/src/Parsers/ParserSelectWithUnionQuery.cpp:15: DB::ParserSelectWithUnionQuery::parseImpl(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x0000000017a73745 9. /build/src/Parsers/IParserBase.cpp:14: DB::IParserBase::parse(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x0000000017a36cf0 10. /build/src/Parsers/ExpressionElementParsers.cpp:116: DB::ParserSubquery::parseImpl(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x0000000017a05f3a 11. /build/src/Parsers/IParserBase.cpp:14: DB::IParserBase::parse(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x0000000017a36cf0 12. /build/src/Parsers/ParserUnionQueryElement.cpp:13: DB::ParserUnionQueryElement::parseImpl(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x0000000017a8a1ef 13. /build/src/Parsers/IParserBase.cpp:14: DB::IParserBase::parse(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x0000000017a36cf0 14. /build/src/Parsers/ExpressionListParsers.cpp:82: DB::ParserUnionList::parseImpl(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&)::$_0::operator()() const @ 0x0000000017a23244 15. /build/src/Parsers/ExpressionListParsers.h:89: DB::ParserUnionList::parseImpl(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x0000000017a1ab73 16. /build/src/Parsers/IParserBase.cpp:14: DB::IParserBase::parse(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x0000000017a36cf0 17. /build/src/Parsers/ParserSelectWithUnionQuery.cpp:15: DB::ParserSelectWithUnionQuery::parseImpl(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x0000000017a73745 18. /build/src/Parsers/IParserBase.cpp:14: DB::IParserBase::parse(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x0000000017a36cf0 19. /build/src/Parsers/ExpressionElementParsers.cpp:116: DB::ParserSubquery::parseImpl(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x0000000017a05f3a 20. /build/src/Parsers/IParserBase.cpp:14: DB::IParserBase::parse(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x0000000017a36cf0 21. /build/src/Parsers/ParserUnionQueryElement.cpp:13: DB::ParserUnionQueryElement::parseImpl(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x0000000017a8a1ef 22. /build/src/Parsers/IParserBase.cpp:14: DB::IParserBase::parse(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x0000000017a36cf0 23. /build/src/Parsers/ExpressionListParsers.cpp:82: DB::ParserUnionList::parseImpl(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&)::$_0::operator()() const @ 0x0000000017a23244 24. /build/src/Parsers/ExpressionListParsers.h:89: DB::ParserUnionList::parseImpl(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x0000000017a1ab73 25. /build/src/Parsers/IParserBase.cpp:14: DB::IParserBase::parse(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x0000000017a36cf0 26. /build/src/Parsers/ParserSelectWithUnionQuery.cpp:15: DB::ParserSelectWithUnionQuery::parseImpl(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x0000000017a73745 27. /build/src/Parsers/IParserBase.cpp:14: DB::IParserBase::parse(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x0000000017a36cf0 28. /build/src/Parsers/ExpressionElementParsers.cpp:116: DB::ParserSubquery::parseImpl(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x0000000017a05f3a 29. /build/src/Parsers/IParserBase.cpp:14: DB::IParserBase::parse(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x0000000017a36cf0 30. /build/src/Parsers/ParserUnionQueryElement.cpp:13: DB::ParserUnionQueryElement::parseImpl(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x0000000017a8a1ef 31. /build/src/Parsers/IParserBase.cpp:14: DB::IParserBase::parse(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x0000000017a36cf0 (version 25.3.6.10636.altinitytest (altinity build)) 2025.07.28 11:56:36.062803 [ 5951 ] {37b71c0c-75ad-46da-976b-814fca2be324} executeQuery: Code: 306. DB::Exception: Maximum parse depth (1000) exceeded. Consider rising max_parser_depth parameter. (TOO_DEEP_RECURSION) (version 25.3.6.10636.altinitytest (altinity build)) (from [::ffff:127.0.0.1]:55468) (comment: 00984_parser_stack_overflow.sh) (in query: SELECT [[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[[), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type>, unsigned int&) @ 0x000000000de86fcb 4. /build/src/Parsers/IParser.h:114: DB::IParserBase::parse(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x0000000017a36e93 5. /build/src/Parsers/ExpressionElementParsers.cpp:980: DB::ParserNull::parseImpl(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x0000000017a0c318 6. /build/src/Parsers/IParserBase.cpp:14: DB::IParserBase::parse(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x0000000017a36cf0 7. /build/src/Parsers/ExpressionElementParsers.cpp:1553: DB::ParserLiteral::parseImpl(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x0000000017a0e2dd 8. /build/src/Parsers/IParserBase.cpp:14: DB::IParserBase::parse(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x0000000017a36cf0 9. /build/src/Parsers/ExpressionElementParsers.cpp:1365: DB::ParserCollectionOfLiterals::parseImpl(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x0000000017a16245 10. /build/src/Parsers/IParserBase.cpp:14: DB::IParserBase::parse(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x0000000017a36cf0 11. /build/src/Parsers/IParserBase.cpp:14: DB::IParserBase::parse(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x0000000017a36cf0 12. /build/src/Parsers/ExpressionListParsers.cpp:2624: DB::ParserExpressionImpl::tryParseOperand(std::vector>, std::allocator>>>&, DB::IParser::Pos&, DB::Expected&) @ 0x0000000017a20f7d 13. /build/src/Parsers/ExpressionListParsers.cpp:2465: DB::ParserExpressionImpl::parse(std::unique_ptr>, DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x0000000017a1e88a 14. /build/src/Parsers/ExpressionListParsers.cpp:2331: DB::ParserExpression::parseImpl(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x0000000017a1e68d 15. /build/src/Parsers/IParserBase.cpp:14: DB::IParserBase::parse(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x0000000017a36cf0 16. /build/src/Parsers/ExpressionElementParsers.cpp:2131: DB::ParserWithOptionalAlias::parseImpl(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x0000000017a12284 17. /build/src/Parsers/IParserBase.cpp:14: DB::IParserBase::parse(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x0000000017a36cf0 18. /build/src/Parsers/IParserBase.cpp:14: DB::IParserBase::parse(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x0000000017a36cf0 19. /build/src/Parsers/ExpressionListParsers.cpp:53: DB::ParserList::parseImpl(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&)::$_0::operator()() const @ 0x0000000017a23149 20. /build/src/Parsers/ExpressionListParsers.h:40: DB::ParserList::parseImpl(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x0000000017a1a8e6 21. /build/src/Parsers/IParserBase.cpp:14: DB::IParserBase::parse(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x0000000017a36cf0 22. /build/src/Parsers/ExpressionListParsers.cpp:320: DB::ParserExpressionList::parseImpl(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x0000000017a1c34a 23. /build/src/Parsers/IParserBase.cpp:14: DB::IParserBase::parse(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x0000000017a36cf0 24. /build/src/Parsers/ExpressionListParsers.cpp:325: DB::ParserNotEmptyExpressionList::parseImpl(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x0000000017a1c42d 25. /build/src/Parsers/IParserBase.cpp:14: DB::IParserBase::parse(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x0000000017a36cf0 26. /build/src/Parsers/ParserSelectQuery.cpp:192: DB::ParserSelectQuery::parseImpl(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x0000000017a71bc3 27. /build/src/Parsers/IParserBase.cpp:14: DB::IParserBase::parse(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x0000000017a36cf0 28. /build/src/Parsers/ParserUnionQueryElement.cpp:13: DB::ParserUnionQueryElement::parseImpl(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x0000000017a8a222 29. /build/src/Parsers/IParserBase.cpp:14: DB::IParserBase::parse(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x0000000017a36cf0 30. /build/src/Parsers/ExpressionListParsers.cpp:82: DB::ParserUnionList::parseImpl(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&)::$_0::operator()() const @ 0x0000000017a23244 31. /build/src/Parsers/ExpressionListParsers.h:89: DB::ParserUnionList::parseImpl(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x0000000017a1ab73 2025.07.28 11:56:36.064519 [ 5951 ] {37b71c0c-75ad-46da-976b-814fca2be324} DynamicQueryHandler: Code: 306. DB::Exception: Maximum parse depth (1000) exceeded. Consider rising max_parser_depth parameter. (TOO_DEEP_RECURSION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type>, unsigned int&) @ 0x000000000de86fcb 4. /build/src/Parsers/IParser.h:114: DB::IParserBase::parse(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x0000000017a36e93 5. /build/src/Parsers/ExpressionElementParsers.cpp:980: DB::ParserNull::parseImpl(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x0000000017a0c318 6. /build/src/Parsers/IParserBase.cpp:14: DB::IParserBase::parse(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x0000000017a36cf0 7. /build/src/Parsers/ExpressionElementParsers.cpp:1553: DB::ParserLiteral::parseImpl(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x0000000017a0e2dd 8. /build/src/Parsers/IParserBase.cpp:14: DB::IParserBase::parse(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x0000000017a36cf0 9. /build/src/Parsers/ExpressionElementParsers.cpp:1365: DB::ParserCollectionOfLiterals::parseImpl(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x0000000017a16245 10. /build/src/Parsers/IParserBase.cpp:14: DB::IParserBase::parse(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x0000000017a36cf0 11. /build/src/Parsers/IParserBase.cpp:14: DB::IParserBase::parse(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x0000000017a36cf0 12. /build/src/Parsers/ExpressionListParsers.cpp:2624: DB::ParserExpressionImpl::tryParseOperand(std::vector>, std::allocator>>>&, DB::IParser::Pos&, DB::Expected&) @ 0x0000000017a20f7d 13. /build/src/Parsers/ExpressionListParsers.cpp:2465: DB::ParserExpressionImpl::parse(std::unique_ptr>, DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x0000000017a1e88a 14. /build/src/Parsers/ExpressionListParsers.cpp:2331: DB::ParserExpression::parseImpl(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x0000000017a1e68d 15. /build/src/Parsers/IParserBase.cpp:14: DB::IParserBase::parse(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x0000000017a36cf0 16. /build/src/Parsers/ExpressionElementParsers.cpp:2131: DB::ParserWithOptionalAlias::parseImpl(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x0000000017a12284 17. /build/src/Parsers/IParserBase.cpp:14: DB::IParserBase::parse(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x0000000017a36cf0 18. /build/src/Parsers/IParserBase.cpp:14: DB::IParserBase::parse(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x0000000017a36cf0 19. /build/src/Parsers/ExpressionListParsers.cpp:53: DB::ParserList::parseImpl(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&)::$_0::operator()() const @ 0x0000000017a23149 20. /build/src/Parsers/ExpressionListParsers.h:40: DB::ParserList::parseImpl(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x0000000017a1a8e6 21. /build/src/Parsers/IParserBase.cpp:14: DB::IParserBase::parse(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x0000000017a36cf0 22. /build/src/Parsers/ExpressionListParsers.cpp:320: DB::ParserExpressionList::parseImpl(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x0000000017a1c34a 23. /build/src/Parsers/IParserBase.cpp:14: DB::IParserBase::parse(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x0000000017a36cf0 24. /build/src/Parsers/ExpressionListParsers.cpp:325: DB::ParserNotEmptyExpressionList::parseImpl(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x0000000017a1c42d 25. /build/src/Parsers/IParserBase.cpp:14: DB::IParserBase::parse(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x0000000017a36cf0 26. /build/src/Parsers/ParserSelectQuery.cpp:192: DB::ParserSelectQuery::parseImpl(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x0000000017a71bc3 27. /build/src/Parsers/IParserBase.cpp:14: DB::IParserBase::parse(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x0000000017a36cf0 28. /build/src/Parsers/ParserUnionQueryElement.cpp:13: DB::ParserUnionQueryElement::parseImpl(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x0000000017a8a222 29. /build/src/Parsers/IParserBase.cpp:14: DB::IParserBase::parse(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x0000000017a36cf0 30. /build/src/Parsers/ExpressionListParsers.cpp:82: DB::ParserUnionList::parseImpl(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&)::$_0::operator()() const @ 0x0000000017a23244 31. /build/src/Parsers/ExpressionListParsers.h:89: DB::ParserUnionList::parseImpl(DB::IParser::Pos&, std::shared_ptr&, DB::Expected&) @ 0x0000000017a1ab73 (version 25.3.6.10636.altinitytest (altinity build)) 2025.07.28 11:56:36.170668 [ 3963 ] {} test_13.rmt2 (7f9b740d-015c-470e-8cc6-8ba33be0dc63): auto DB::StorageReplicatedMergeTree::processQueueEntry(ReplicatedMergeTreeQueue::SelectedEntryPtr)::(anonymous class)::operator()(LogEntryPtr &) const: Code: 86. DB::HTTPException: Received error from remote server http://146b4357c08d:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Ftest%2F01165%2Ftest_13%2Frmt%2Freplicas%2F1&part=20250728_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.6.10636.altinitytest (altinity build)) '. (RECEIVED_ERROR_FROM_REMOTE_IO_SERVER), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.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 const&, int&&, String const&, unsigned long&&, String const&) @ 0x000000000feda8d9 4. /build/src/IO/HTTPCommon.cpp:104: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x000000000feda6e2 5. /build/src/IO/HTTPCommon.cpp:93: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x000000000feda537 6. /build/src/IO/ReadWriteBufferFromHTTP.cpp:277: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x000000001184a4c4 7. /build/src/IO/ReadWriteBufferFromHTTP.cpp:285: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x000000001184a615 8. /build/src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x000000001184ae59 9. /build/src/IO/ReadWriteBufferFromHTTP.cpp:472: void std::__function::__policy_invoker::__call_impl[abi:se190107]>(std::__function::__policy_storage const*) @ 0x000000001184cedd 10. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001184858b 11. /build/src/IO/ReadWriteBufferFromHTTP.cpp:465: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x000000001184bf0b 12. /build/src/IO/ReadBuffer.h:60: DB::ReadBuffer::next() @ 0x000000000a148c7b 13. /build/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) @ 0x0000000011849fb2 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]>&)>&, 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&) @ 0x0000000011841980 15. /build/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) @ 0x000000001621208e 16. /build/src/Storages/StorageReplicatedMergeTree.cpp:5228: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl[abi:se190107] const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000015f9a5fe 17. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000015ed8bfd 18. /build/src/Storages/StorageReplicatedMergeTree.cpp:2514: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x0000000015ec9aab 19. /build/src/Storages/StorageReplicatedMergeTree.cpp:2349: DB::StorageReplicatedMergeTree::executeLogEntry(DB::ReplicatedMergeTreeLogEntry&) @ 0x0000000015eba91b 20. /build/src/Storages/StorageReplicatedMergeTree.cpp:3876: bool std::__function::__policy_invoker&)>::__call_impl[abi:se190107])::$_1, bool (std::shared_ptr&)>>(std::__function::__policy_storage const*, std::shared_ptr&) @ 0x0000000015f9837e 21. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000165d6fc3 22. /build/src/Storages/StorageReplicatedMergeTree.cpp:3872: DB::StorageReplicatedMergeTree::processQueueEntry(std::shared_ptr) @ 0x0000000015efc18a 23. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001624c1b2 24. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000162f9c70 25. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x00000000162fa55a 26. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc6653 27. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000000fccc4c3 28. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc3d92 29. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fcca080 30. ? @ 0x00007fbc6213eac3 31. ? @ 0x00007fbc621d0850 (version 25.3.6.10636.altinitytest (altinity build)) 2025.07.28 11:56:36.973145 [ 3965 ] {} test_13.rmt2 (7f9b740d-015c-470e-8cc6-8ba33be0dc63): auto DB::StorageReplicatedMergeTree::processQueueEntry(ReplicatedMergeTreeQueue::SelectedEntryPtr)::(anonymous class)::operator()(LogEntryPtr &) const: Code: 86. DB::HTTPException: Received error from remote server http://146b4357c08d:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Ftest%2F01165%2Ftest_13%2Frmt%2Freplicas%2F1&part=20250728_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.6.10636.altinitytest (altinity build)) '. (RECEIVED_ERROR_FROM_REMOTE_IO_SERVER), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.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 const&, int&&, String const&, unsigned long&&, String const&) @ 0x000000000feda8d9 4. /build/src/IO/HTTPCommon.cpp:104: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x000000000feda6e2 5. /build/src/IO/HTTPCommon.cpp:93: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x000000000feda537 6. /build/src/IO/ReadWriteBufferFromHTTP.cpp:277: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x000000001184a4c4 7. /build/src/IO/ReadWriteBufferFromHTTP.cpp:285: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x000000001184a615 8. /build/src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x000000001184ae59 9. /build/src/IO/ReadWriteBufferFromHTTP.cpp:472: void std::__function::__policy_invoker::__call_impl[abi:se190107]>(std::__function::__policy_storage const*) @ 0x000000001184cedd 10. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001184858b 11. /build/src/IO/ReadWriteBufferFromHTTP.cpp:465: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x000000001184bf0b 12. /build/src/IO/ReadBuffer.h:60: DB::ReadBuffer::next() @ 0x000000000a148c7b 13. /build/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) @ 0x0000000011849fb2 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]>&)>&, 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&) @ 0x0000000011841980 15. /build/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) @ 0x000000001621208e 16. /build/src/Storages/StorageReplicatedMergeTree.cpp:5228: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl[abi:se190107] const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000015f9a5fe 17. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000015ed8bfd 18. /build/src/Storages/StorageReplicatedMergeTree.cpp:2514: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x0000000015ec9aab 19. /build/src/Storages/StorageReplicatedMergeTree.cpp:2349: DB::StorageReplicatedMergeTree::executeLogEntry(DB::ReplicatedMergeTreeLogEntry&) @ 0x0000000015eba91b 20. /build/src/Storages/StorageReplicatedMergeTree.cpp:3876: bool std::__function::__policy_invoker&)>::__call_impl[abi:se190107])::$_1, bool (std::shared_ptr&)>>(std::__function::__policy_storage const*, std::shared_ptr&) @ 0x0000000015f9837e 21. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000165d6fc3 22. /build/src/Storages/StorageReplicatedMergeTree.cpp:3872: DB::StorageReplicatedMergeTree::processQueueEntry(std::shared_ptr) @ 0x0000000015efc18a 23. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001624c1b2 24. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000162f9c70 25. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x00000000162fa55a 26. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc6653 27. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000000fccc4c3 28. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc3d92 29. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fcca080 30. ? @ 0x00007fbc6213eac3 31. ? @ 0x00007fbc621d0850 (version 25.3.6.10636.altinitytest (altinity build)) 2025.07.28 11:56:37.624095 [ 3287 ] {} 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. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x000000000c25bc4b 4. /build/src/Access/SettingsConstraints.cpp:343: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000138596e3 5. /build/src/Access/SettingsConstraints.cpp:300: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000013858faf 6. /build/src/Access/SettingsConstraints.cpp:209: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x00000000138592b8 7. /build/src/Interpreters/Context.cpp:2690: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000014436134 8. /build/src/Interpreters/Context.cpp:2729: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x000000001443662b 9. /build/src/Server/TCPHandler.cpp:2158: DB::TCPHandler::processQuery(std::optional&) @ 0x00000000168f61df 10. /build/src/Server/TCPHandler.cpp:918: DB::TCPHandler::receivePacketsExpectQuery(std::optional&) @ 0x00000000168ef965 11. /build/src/Server/TCPHandler.cpp:491: DB::TCPHandler::runImpl() @ 0x00000000168e5eb4 12. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 13. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 14. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 16. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 17. ? @ 0x00007fbc6213eac3 18. ? @ 0x00007fbc621d0850 2025.07.28 11:56:37.632236 [ 3287 ] {} 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. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000000a074fcb 4. /build/src/Server/TCPHandler.cpp:897: DB::TCPHandler::receivePacketsExpectQuery(std::optional&) @ 0x00000000168efa89 5. /build/src/Server/TCPHandler.cpp:491: DB::TCPHandler::runImpl() @ 0x00000000168e5eb4 6. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 7. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 8. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 9. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 10. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 11. ? @ 0x00007fbc6213eac3 12. ? @ 0x00007fbc621d0850 2025.07.28 11:56:37.861465 [ 3961 ] {} test_13.rmt2 (7f9b740d-015c-470e-8cc6-8ba33be0dc63): auto DB::StorageReplicatedMergeTree::processQueueEntry(ReplicatedMergeTreeQueue::SelectedEntryPtr)::(anonymous class)::operator()(LogEntryPtr &) const: Code: 86. DB::HTTPException: Received error from remote server http://146b4357c08d:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Ftest%2F01165%2Ftest_13%2Frmt%2Freplicas%2F1&part=20250728_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.6.10636.altinitytest (altinity build)) '. (RECEIVED_ERROR_FROM_REMOTE_IO_SERVER), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.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 const&, int&&, String const&, unsigned long&&, String const&) @ 0x000000000feda8d9 4. /build/src/IO/HTTPCommon.cpp:104: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x000000000feda6e2 5. /build/src/IO/HTTPCommon.cpp:93: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x000000000feda537 6. /build/src/IO/ReadWriteBufferFromHTTP.cpp:277: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x000000001184a4c4 7. /build/src/IO/ReadWriteBufferFromHTTP.cpp:285: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x000000001184a615 8. /build/src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x000000001184ae59 9. /build/src/IO/ReadWriteBufferFromHTTP.cpp:472: void std::__function::__policy_invoker::__call_impl[abi:se190107]>(std::__function::__policy_storage const*) @ 0x000000001184cedd 10. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001184858b 11. /build/src/IO/ReadWriteBufferFromHTTP.cpp:465: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x000000001184bf0b 12. /build/src/IO/ReadBuffer.h:60: DB::ReadBuffer::next() @ 0x000000000a148c7b 13. /build/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) @ 0x0000000011849fb2 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]>&)>&, 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&) @ 0x0000000011841980 15. /build/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) @ 0x000000001621208e 16. /build/src/Storages/StorageReplicatedMergeTree.cpp:5228: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl[abi:se190107] const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000015f9a5fe 17. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000015ed8bfd 18. /build/src/Storages/StorageReplicatedMergeTree.cpp:2514: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x0000000015ec9aab 19. /build/src/Storages/StorageReplicatedMergeTree.cpp:2349: DB::StorageReplicatedMergeTree::executeLogEntry(DB::ReplicatedMergeTreeLogEntry&) @ 0x0000000015eba91b 20. /build/src/Storages/StorageReplicatedMergeTree.cpp:3876: bool std::__function::__policy_invoker&)>::__call_impl[abi:se190107])::$_1, bool (std::shared_ptr&)>>(std::__function::__policy_storage const*, std::shared_ptr&) @ 0x0000000015f9837e 21. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000165d6fc3 22. /build/src/Storages/StorageReplicatedMergeTree.cpp:3872: DB::StorageReplicatedMergeTree::processQueueEntry(std::shared_ptr) @ 0x0000000015efc18a 23. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001624c1b2 24. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000162f9c70 25. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x00000000162fa55a 26. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc6653 27. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000000fccc4c3 28. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc3d92 29. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fcca080 30. ? @ 0x00007fbc6213eac3 31. ? @ 0x00007fbc621d0850 (version 25.3.6.10636.altinitytest (altinity build)) 2025.07.28 11:56:38.768804 [ 3967 ] {} test_13.rmt2 (7f9b740d-015c-470e-8cc6-8ba33be0dc63): auto DB::StorageReplicatedMergeTree::processQueueEntry(ReplicatedMergeTreeQueue::SelectedEntryPtr)::(anonymous class)::operator()(LogEntryPtr &) const: Code: 86. DB::HTTPException: Received error from remote server http://146b4357c08d:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Ftest%2F01165%2Ftest_13%2Frmt%2Freplicas%2F1&part=20250728_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.6.10636.altinitytest (altinity build)) '. (RECEIVED_ERROR_FROM_REMOTE_IO_SERVER), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.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 const&, int&&, String const&, unsigned long&&, String const&) @ 0x000000000feda8d9 4. /build/src/IO/HTTPCommon.cpp:104: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x000000000feda6e2 5. /build/src/IO/HTTPCommon.cpp:93: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x000000000feda537 6. /build/src/IO/ReadWriteBufferFromHTTP.cpp:277: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x000000001184a4c4 7. /build/src/IO/ReadWriteBufferFromHTTP.cpp:285: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x000000001184a615 8. /build/src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x000000001184ae59 9. /build/src/IO/ReadWriteBufferFromHTTP.cpp:472: void std::__function::__policy_invoker::__call_impl[abi:se190107]>(std::__function::__policy_storage const*) @ 0x000000001184cedd 10. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001184858b 11. /build/src/IO/ReadWriteBufferFromHTTP.cpp:465: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x000000001184bf0b 12. /build/src/IO/ReadBuffer.h:60: DB::ReadBuffer::next() @ 0x000000000a148c7b 13. /build/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) @ 0x0000000011849fb2 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]>&)>&, 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&) @ 0x0000000011841980 15. /build/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) @ 0x000000001621208e 16. /build/src/Storages/StorageReplicatedMergeTree.cpp:5228: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl[abi:se190107] const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000015f9a5fe 17. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000015ed8bfd 18. /build/src/Storages/StorageReplicatedMergeTree.cpp:2514: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x0000000015ec9aab 19. /build/src/Storages/StorageReplicatedMergeTree.cpp:2349: DB::StorageReplicatedMergeTree::executeLogEntry(DB::ReplicatedMergeTreeLogEntry&) @ 0x0000000015eba91b 20. /build/src/Storages/StorageReplicatedMergeTree.cpp:3876: bool std::__function::__policy_invoker&)>::__call_impl[abi:se190107])::$_1, bool (std::shared_ptr&)>>(std::__function::__policy_storage const*, std::shared_ptr&) @ 0x0000000015f9837e 21. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000165d6fc3 22. /build/src/Storages/StorageReplicatedMergeTree.cpp:3872: DB::StorageReplicatedMergeTree::processQueueEntry(std::shared_ptr) @ 0x0000000015efc18a 23. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001624c1b2 24. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000162f9c70 25. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x00000000162fa55a 26. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc6653 27. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000000fccc4c3 28. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc3d92 29. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fcca080 30. ? @ 0x00007fbc6213eac3 31. ? @ 0x00007fbc621d0850 (version 25.3.6.10636.altinitytest (altinity build)) 2025.07.28 11:56:39.152723 [ 3963 ] {} test_13.rmt2 (7f9b740d-015c-470e-8cc6-8ba33be0dc63): auto DB::StorageReplicatedMergeTree::processQueueEntry(ReplicatedMergeTreeQueue::SelectedEntryPtr)::(anonymous class)::operator()(LogEntryPtr &) const: Code: 86. DB::HTTPException: Received error from remote server http://146b4357c08d:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Ftest%2F01165%2Ftest_13%2Frmt%2Freplicas%2F1&part=20250728_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.6.10636.altinitytest (altinity build)) '. (RECEIVED_ERROR_FROM_REMOTE_IO_SERVER), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.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 const&, int&&, String const&, unsigned long&&, String const&) @ 0x000000000feda8d9 4. /build/src/IO/HTTPCommon.cpp:104: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x000000000feda6e2 5. /build/src/IO/HTTPCommon.cpp:93: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x000000000feda537 6. /build/src/IO/ReadWriteBufferFromHTTP.cpp:277: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x000000001184a4c4 7. /build/src/IO/ReadWriteBufferFromHTTP.cpp:285: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x000000001184a615 8. /build/src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x000000001184ae59 9. /build/src/IO/ReadWriteBufferFromHTTP.cpp:472: void std::__function::__policy_invoker::__call_impl[abi:se190107]>(std::__function::__policy_storage const*) @ 0x000000001184cedd 10. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001184858b 11. /build/src/IO/ReadWriteBufferFromHTTP.cpp:465: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x000000001184bf0b 12. /build/src/IO/ReadBuffer.h:60: DB::ReadBuffer::next() @ 0x000000000a148c7b 13. /build/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) @ 0x0000000011849fb2 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]>&)>&, 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&) @ 0x0000000011841980 15. /build/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) @ 0x000000001621208e 16. /build/src/Storages/StorageReplicatedMergeTree.cpp:5228: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl[abi:se190107] const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000015f9a5fe 17. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000015ed8bfd 18. /build/src/Storages/StorageReplicatedMergeTree.cpp:2514: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x0000000015ec9aab 19. /build/src/Storages/StorageReplicatedMergeTree.cpp:2349: DB::StorageReplicatedMergeTree::executeLogEntry(DB::ReplicatedMergeTreeLogEntry&) @ 0x0000000015eba91b 20. /build/src/Storages/StorageReplicatedMergeTree.cpp:3876: bool std::__function::__policy_invoker&)>::__call_impl[abi:se190107])::$_1, bool (std::shared_ptr&)>>(std::__function::__policy_storage const*, std::shared_ptr&) @ 0x0000000015f9837e 21. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000165d6fc3 22. /build/src/Storages/StorageReplicatedMergeTree.cpp:3872: DB::StorageReplicatedMergeTree::processQueueEntry(std::shared_ptr) @ 0x0000000015efc18a 23. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001624c1b2 24. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000162f9c70 25. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x00000000162fa55a 26. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc6653 27. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000000fccc4c3 28. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc3d92 29. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fcca080 30. ? @ 0x00007fbc6213eac3 31. ? @ 0x00007fbc621d0850 (version 25.3.6.10636.altinitytest (altinity build)) 2025.07.28 11:56:39.849336 [ 17207 ] {74408333-e87a-4724-bdb3-80fd2079928e} executeQuery: Code: 62. DB::Exception: Syntax error: failed at position 8 ((): ([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([... Unmatched parentheses: ([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([. (SYNTAX_ERROR) (version 25.3.6.10636.altinitytest (altinity build)) (from [::ffff:127.0.0.1]:55474) (comment: 00984_parser_stack_overflow.sh) (in query: SELECT ([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:111: DB::Exception::createDeprecated(String const&, int, bool) @ 0x000000000a08e96d 3. /build/src/Parsers/parseQuery.cpp:411: DB::parseQueryAndMovePosition(DB::IParser&, char const*&, char const*, String const&, bool, unsigned long, unsigned long, unsigned long) @ 0x0000000017a96b2c 4. /build/src/Parsers/parseQuery.cpp:424: DB::parseQuery(DB::IParser&, char const*, char const*, String const&, unsigned long, unsigned long, unsigned long) @ 0x0000000017a96bbe 5. /build/src/Interpreters/executeQuery.cpp:955: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c8533e 6. /build/src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x0000000014c8ca7b 7. /build/src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000001686da12 8. /build/src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x0000000016870807 9. /build/src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x0000000016907e99 10. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 11. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 12. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 13. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 14. ? @ 0x00007fbc6213eac3 15. ? @ 0x00007fbc621d0850 2025.07.28 11:56:39.851690 [ 17207 ] {74408333-e87a-4724-bdb3-80fd2079928e} DynamicQueryHandler: Code: 62. DB::Exception: Syntax error: failed at position 8 ((): ([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([... Unmatched parentheses: ([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([([. (SYNTAX_ERROR), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:111: DB::Exception::createDeprecated(String const&, int, bool) @ 0x000000000a08e96d 3. /build/src/Parsers/parseQuery.cpp:411: DB::parseQueryAndMovePosition(DB::IParser&, char const*&, char const*, String const&, bool, unsigned long, unsigned long, unsigned long) @ 0x0000000017a96b2c 4. /build/src/Parsers/parseQuery.cpp:424: DB::parseQuery(DB::IParser&, char const*, char const*, String const&, unsigned long, unsigned long, unsigned long) @ 0x0000000017a96bbe 5. /build/src/Interpreters/executeQuery.cpp:955: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c8533e 6. /build/src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x0000000014c8ca7b 7. /build/src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000001686da12 8. /build/src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x0000000016870807 9. /build/src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x0000000016907e99 10. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 11. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 12. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 13. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 14. ? @ 0x00007fbc6213eac3 15. ? @ 0x00007fbc621d0850 (version 25.3.6.10636.altinitytest (altinity build)) 2025.07.28 11:56:39.937955 [ 3972 ] {} test_13.rmt2 (7f9b740d-015c-470e-8cc6-8ba33be0dc63): auto DB::StorageReplicatedMergeTree::processQueueEntry(ReplicatedMergeTreeQueue::SelectedEntryPtr)::(anonymous class)::operator()(LogEntryPtr &) const: Code: 86. DB::HTTPException: Received error from remote server http://146b4357c08d:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Ftest%2F01165%2Ftest_13%2Frmt%2Freplicas%2F1&part=20250728_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.6.10636.altinitytest (altinity build)) '. (RECEIVED_ERROR_FROM_REMOTE_IO_SERVER), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.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 const&, int&&, String const&, unsigned long&&, String const&) @ 0x000000000feda8d9 4. /build/src/IO/HTTPCommon.cpp:104: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x000000000feda6e2 5. /build/src/IO/HTTPCommon.cpp:93: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x000000000feda537 6. /build/src/IO/ReadWriteBufferFromHTTP.cpp:277: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x000000001184a4c4 7. /build/src/IO/ReadWriteBufferFromHTTP.cpp:285: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x000000001184a615 8. /build/src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x000000001184ae59 9. /build/src/IO/ReadWriteBufferFromHTTP.cpp:472: void std::__function::__policy_invoker::__call_impl[abi:se190107]>(std::__function::__policy_storage const*) @ 0x000000001184cedd 10. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001184858b 11. /build/src/IO/ReadWriteBufferFromHTTP.cpp:465: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x000000001184bf0b 12. /build/src/IO/ReadBuffer.h:60: DB::ReadBuffer::next() @ 0x000000000a148c7b 13. /build/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) @ 0x0000000011849fb2 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]>&)>&, 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&) @ 0x0000000011841980 15. /build/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) @ 0x000000001621208e 16. /build/src/Storages/StorageReplicatedMergeTree.cpp:5228: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl[abi:se190107] const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000015f9a5fe 17. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000015ed8bfd 18. /build/src/Storages/StorageReplicatedMergeTree.cpp:2514: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x0000000015ec9aab 19. /build/src/Storages/StorageReplicatedMergeTree.cpp:2349: DB::StorageReplicatedMergeTree::executeLogEntry(DB::ReplicatedMergeTreeLogEntry&) @ 0x0000000015eba91b 20. /build/src/Storages/StorageReplicatedMergeTree.cpp:3876: bool std::__function::__policy_invoker&)>::__call_impl[abi:se190107])::$_1, bool (std::shared_ptr&)>>(std::__function::__policy_storage const*, std::shared_ptr&) @ 0x0000000015f9837e 21. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000165d6fc3 22. /build/src/Storages/StorageReplicatedMergeTree.cpp:3872: DB::StorageReplicatedMergeTree::processQueueEntry(std::shared_ptr) @ 0x0000000015efc18a 23. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001624c1b2 24. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000162f9c70 25. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x00000000162fa55a 26. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc6653 27. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000000fccc4c3 28. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc3d92 29. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fcca080 30. ? @ 0x00007fbc6213eac3 31. ? @ 0x00007fbc621d0850 (version 25.3.6.10636.altinitytest (altinity build)) 2025.07.28 11:56:40.824201 [ 3976 ] {} test_13.rmt2 (7f9b740d-015c-470e-8cc6-8ba33be0dc63): auto DB::StorageReplicatedMergeTree::processQueueEntry(ReplicatedMergeTreeQueue::SelectedEntryPtr)::(anonymous class)::operator()(LogEntryPtr &) const: Code: 86. DB::HTTPException: Received error from remote server http://146b4357c08d:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Ftest%2F01165%2Ftest_13%2Frmt%2Freplicas%2F1&part=20250728_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.6.10636.altinitytest (altinity build)) '. (RECEIVED_ERROR_FROM_REMOTE_IO_SERVER), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.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 const&, int&&, String const&, unsigned long&&, String const&) @ 0x000000000feda8d9 4. /build/src/IO/HTTPCommon.cpp:104: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x000000000feda6e2 5. /build/src/IO/HTTPCommon.cpp:93: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x000000000feda537 6. /build/src/IO/ReadWriteBufferFromHTTP.cpp:277: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x000000001184a4c4 7. /build/src/IO/ReadWriteBufferFromHTTP.cpp:285: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x000000001184a615 8. /build/src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x000000001184ae59 9. /build/src/IO/ReadWriteBufferFromHTTP.cpp:472: void std::__function::__policy_invoker::__call_impl[abi:se190107]>(std::__function::__policy_storage const*) @ 0x000000001184cedd 10. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001184858b 11. /build/src/IO/ReadWriteBufferFromHTTP.cpp:465: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x000000001184bf0b 12. /build/src/IO/ReadBuffer.h:60: DB::ReadBuffer::next() @ 0x000000000a148c7b 13. /build/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) @ 0x0000000011849fb2 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]>&)>&, 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&) @ 0x0000000011841980 15. /build/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) @ 0x000000001621208e 16. /build/src/Storages/StorageReplicatedMergeTree.cpp:5228: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl[abi:se190107] const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000015f9a5fe 17. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000015ed8bfd 18. /build/src/Storages/StorageReplicatedMergeTree.cpp:2514: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x0000000015ec9aab 19. /build/src/Storages/StorageReplicatedMergeTree.cpp:2349: DB::StorageReplicatedMergeTree::executeLogEntry(DB::ReplicatedMergeTreeLogEntry&) @ 0x0000000015eba91b 20. /build/src/Storages/StorageReplicatedMergeTree.cpp:3876: bool std::__function::__policy_invoker&)>::__call_impl[abi:se190107])::$_1, bool (std::shared_ptr&)>>(std::__function::__policy_storage const*, std::shared_ptr&) @ 0x0000000015f9837e 21. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000165d6fc3 22. /build/src/Storages/StorageReplicatedMergeTree.cpp:3872: DB::StorageReplicatedMergeTree::processQueueEntry(std::shared_ptr) @ 0x0000000015efc18a 23. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001624c1b2 24. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000162f9c70 25. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x00000000162fa55a 26. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc6653 27. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000000fccc4c3 28. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc3d92 29. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fcca080 30. ? @ 0x00007fbc6213eac3 31. ? @ 0x00007fbc621d0850 (version 25.3.6.10636.altinitytest (altinity build)) 2025.07.28 11:56:40.935502 [ 11826 ] {6eaed6fa-87f8-49ad-953b-90a2cc144a15} executeQuery: Code: 167. DB::Exception: AST is too deep. Maximum: 1000. (TOO_DEEP_AST) (version 25.3.6.10636.altinitytest (altinity build)) (from [::ffff:127.0.0.1]:55486) (comment: 00984_parser_stack_overflow.sh) (in query: SELECT 1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1+1), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type>, unsigned long&) @ 0x000000000b23df2b 4. /build/src/Parsers/IAST.cpp:162: DB::IAST::checkDepthImpl(unsigned long) const @ 0x0000000017a3576f 5. /build/src/Parsers/IAST.h:99: DB::tryParseQuery(DB::IParser&, char const*&, char const*, String&, bool, String const&, bool, unsigned long, unsigned long, unsigned long, bool) @ 0x0000000017a95b0c 6. /build/src/Parsers/parseQuery.cpp:404: DB::parseQueryAndMovePosition(DB::IParser&, char const*&, char const*, String const&, bool, unsigned long, unsigned long, unsigned long) @ 0x0000000017a96ac6 7. /build/src/Parsers/parseQuery.cpp:424: DB::parseQuery(DB::IParser&, char const*, char const*, String const&, unsigned long, unsigned long, unsigned long) @ 0x0000000017a96bbe 8. /build/src/Interpreters/executeQuery.cpp:955: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c8533e 9. /build/src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x0000000014c8ca7b 10. /build/src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000001686da12 11. /build/src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x0000000016870807 12. /build/src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x0000000016907e99 13. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 14. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 16. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 17. ? @ 0x00007fbc6213eac3 18. ? @ 0x00007fbc621d0850 2025.07.28 11:56:40.946106 [ 11826 ] {6eaed6fa-87f8-49ad-953b-90a2cc144a15} DynamicQueryHandler: Code: 167. DB::Exception: AST is too deep. Maximum: 1000. (TOO_DEEP_AST), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type>, unsigned long&) @ 0x000000000b23df2b 4. /build/src/Parsers/IAST.cpp:162: DB::IAST::checkDepthImpl(unsigned long) const @ 0x0000000017a3576f 5. /build/src/Parsers/IAST.h:99: DB::tryParseQuery(DB::IParser&, char const*&, char const*, String&, bool, String const&, bool, unsigned long, unsigned long, unsigned long, bool) @ 0x0000000017a95b0c 6. /build/src/Parsers/parseQuery.cpp:404: DB::parseQueryAndMovePosition(DB::IParser&, char const*&, char const*, String const&, bool, unsigned long, unsigned long, unsigned long) @ 0x0000000017a96ac6 7. /build/src/Parsers/parseQuery.cpp:424: DB::parseQuery(DB::IParser&, char const*, char const*, String const&, unsigned long, unsigned long, unsigned long) @ 0x0000000017a96bbe 8. /build/src/Interpreters/executeQuery.cpp:955: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c8533e 9. /build/src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x0000000014c8ca7b 10. /build/src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000001686da12 11. /build/src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x0000000016870807 12. /build/src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x0000000016907e99 13. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 14. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 16. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 17. ? @ 0x00007fbc6213eac3 18. ? @ 0x00007fbc621d0850 (version 25.3.6.10636.altinitytest (altinity build)) 2025.07.28 11:56:41.016388 [ 3960 ] {} test_13.rmt2 (7f9b740d-015c-470e-8cc6-8ba33be0dc63): auto DB::StorageReplicatedMergeTree::processQueueEntry(ReplicatedMergeTreeQueue::SelectedEntryPtr)::(anonymous class)::operator()(LogEntryPtr &) const: Code: 86. DB::HTTPException: Received error from remote server http://146b4357c08d:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Ftest%2F01165%2Ftest_13%2Frmt%2Freplicas%2F1&part=20250728_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.6.10636.altinitytest (altinity build)) '. (RECEIVED_ERROR_FROM_REMOTE_IO_SERVER), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.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 const&, int&&, String const&, unsigned long&&, String const&) @ 0x000000000feda8d9 4. /build/src/IO/HTTPCommon.cpp:104: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x000000000feda6e2 5. /build/src/IO/HTTPCommon.cpp:93: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x000000000feda537 6. /build/src/IO/ReadWriteBufferFromHTTP.cpp:277: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x000000001184a4c4 7. /build/src/IO/ReadWriteBufferFromHTTP.cpp:285: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x000000001184a615 8. /build/src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x000000001184ae59 9. /build/src/IO/ReadWriteBufferFromHTTP.cpp:472: void std::__function::__policy_invoker::__call_impl[abi:se190107]>(std::__function::__policy_storage const*) @ 0x000000001184cedd 10. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001184858b 11. /build/src/IO/ReadWriteBufferFromHTTP.cpp:465: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x000000001184bf0b 12. /build/src/IO/ReadBuffer.h:60: DB::ReadBuffer::next() @ 0x000000000a148c7b 13. /build/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) @ 0x0000000011849fb2 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]>&)>&, 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&) @ 0x0000000011841980 15. /build/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) @ 0x000000001621208e 16. /build/src/Storages/StorageReplicatedMergeTree.cpp:5228: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl[abi:se190107] const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000015f9a5fe 17. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000015ed8bfd 18. /build/src/Storages/StorageReplicatedMergeTree.cpp:2514: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x0000000015ec9aab 19. /build/src/Storages/StorageReplicatedMergeTree.cpp:2349: DB::StorageReplicatedMergeTree::executeLogEntry(DB::ReplicatedMergeTreeLogEntry&) @ 0x0000000015eba91b 20. /build/src/Storages/StorageReplicatedMergeTree.cpp:3876: bool std::__function::__policy_invoker&)>::__call_impl[abi:se190107])::$_1, bool (std::shared_ptr&)>>(std::__function::__policy_storage const*, std::shared_ptr&) @ 0x0000000015f9837e 21. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000165d6fc3 22. /build/src/Storages/StorageReplicatedMergeTree.cpp:3872: DB::StorageReplicatedMergeTree::processQueueEntry(std::shared_ptr) @ 0x0000000015efc18a 23. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001624c1b2 24. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000162f9c70 25. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x00000000162fa55a 26. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc6653 27. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000000fccc4c3 28. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc3d92 29. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fcca080 30. ? @ 0x00007fbc6213eac3 31. ? @ 0x00007fbc621d0850 (version 25.3.6.10636.altinitytest (altinity build)) 2025.07.28 11:56:41.300553 [ 3964 ] {} test_13.rmt2 (7f9b740d-015c-470e-8cc6-8ba33be0dc63): auto DB::StorageReplicatedMergeTree::processQueueEntry(ReplicatedMergeTreeQueue::SelectedEntryPtr)::(anonymous class)::operator()(LogEntryPtr &) const: Code: 86. DB::HTTPException: Received error from remote server http://146b4357c08d:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Ftest%2F01165%2Ftest_13%2Frmt%2Freplicas%2F1&part=20250728_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.6.10636.altinitytest (altinity build)) '. (RECEIVED_ERROR_FROM_REMOTE_IO_SERVER), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.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 const&, int&&, String const&, unsigned long&&, String const&) @ 0x000000000feda8d9 4. /build/src/IO/HTTPCommon.cpp:104: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x000000000feda6e2 5. /build/src/IO/HTTPCommon.cpp:93: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x000000000feda537 6. /build/src/IO/ReadWriteBufferFromHTTP.cpp:277: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x000000001184a4c4 7. /build/src/IO/ReadWriteBufferFromHTTP.cpp:285: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x000000001184a615 8. /build/src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x000000001184ae59 9. /build/src/IO/ReadWriteBufferFromHTTP.cpp:472: void std::__function::__policy_invoker::__call_impl[abi:se190107]>(std::__function::__policy_storage const*) @ 0x000000001184cedd 10. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001184858b 11. /build/src/IO/ReadWriteBufferFromHTTP.cpp:465: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x000000001184bf0b 12. /build/src/IO/ReadBuffer.h:60: DB::ReadBuffer::next() @ 0x000000000a148c7b 13. /build/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) @ 0x0000000011849fb2 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]>&)>&, 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&) @ 0x0000000011841980 15. /build/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) @ 0x000000001621208e 16. /build/src/Storages/StorageReplicatedMergeTree.cpp:5228: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl[abi:se190107] const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000015f9a5fe 17. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000015ed8bfd 18. /build/src/Storages/StorageReplicatedMergeTree.cpp:2514: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x0000000015ec9aab 19. /build/src/Storages/StorageReplicatedMergeTree.cpp:2349: DB::StorageReplicatedMergeTree::executeLogEntry(DB::ReplicatedMergeTreeLogEntry&) @ 0x0000000015eba91b 20. /build/src/Storages/StorageReplicatedMergeTree.cpp:3876: bool std::__function::__policy_invoker&)>::__call_impl[abi:se190107])::$_1, bool (std::shared_ptr&)>>(std::__function::__policy_storage const*, std::shared_ptr&) @ 0x0000000015f9837e 21. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000165d6fc3 22. /build/src/Storages/StorageReplicatedMergeTree.cpp:3872: DB::StorageReplicatedMergeTree::processQueueEntry(std::shared_ptr) @ 0x0000000015efc18a 23. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001624c1b2 24. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000162f9c70 25. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x00000000162fa55a 26. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc6653 27. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000000fccc4c3 28. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc3d92 29. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fcca080 30. ? @ 0x00007fbc6213eac3 31. ? @ 0x00007fbc621d0850 (version 25.3.6.10636.altinitytest (altinity build)) 2025.07.28 11:56:41.388573 [ 3287 ] {b78cb342-f172-40f7-963b-a44e12af9232} executeQuery: Code: 507. DB::Exception: Sharding key modulo(key, 2) is not used. (UNABLE_TO_SKIP_UNUSED_SHARDS) (version 25.3.6.10636.altinitytest (altinity build)) (from [::1]:56432) (comment: 01072_optimize_skip_unused_shards_const_expr_eval.sql) (query 14, line 19) (in query: select * from dist_01072 where key=value;), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000a9b78ab 4. /build/src/Storages/StorageDistributed.cpp:1559: DB::StorageDistributed::getOptimizedCluster(std::shared_ptr, std::shared_ptr const&, DB::SelectQueryInfo const&, std::shared_ptr const&) const @ 0x0000000015d6083b 5. /build/src/Storages/StorageDistributed.cpp:457: DB::StorageDistributed::getQueryProcessingStage(std::shared_ptr, DB::QueryProcessingStage::Enum, std::shared_ptr const&, DB::SelectQueryInfo&) const @ 0x0000000015d5f50d 6. /build/src/Planner/PlannerJoinTree.cpp:921: DB::(anonymous namespace)::buildQueryPlanForTableExpression(std::shared_ptr, std::shared_ptr const&, DB::SelectQueryInfo const&, DB::SelectQueryOptions const&, std::shared_ptr&, bool, bool) @ 0x0000000014996f1b 7. /build/src/Planner/PlannerJoinTree.cpp:2252: DB::buildJoinTreeQueryPlan(std::shared_ptr const&, DB::SelectQueryInfo const&, DB::SelectQueryOptions&, std::unordered_set, std::equal_to, std::allocator> const&, std::shared_ptr&) @ 0x000000001498e109 8. /build/src/Planner/Planner.cpp:1553: DB::Planner::buildPlanForQueryNode() @ 0x0000000014979dae 9. /build/src/Planner/Planner.cpp:1308: DB::Planner::buildQueryPlanIfNeeded() @ 0x000000001497685c 10. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:255: DB::InterpreterSelectQueryAnalyzer::getQueryPlan() @ 0x000000001497476d 11. /build/src/Interpreters/executeQuery.cpp:1405: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88806 12. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 13. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 14. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 15. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 16. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 17. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 18. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 19. ? @ 0x00007fbc6213eac3 20. ? @ 0x00007fbc621d0850 2025.07.28 11:56:41.401670 [ 3287 ] {} TCPHandler: Code: 507. DB::Exception: Sharding key modulo(key, 2) is not used. (UNABLE_TO_SKIP_UNUSED_SHARDS), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000a9b78ab 4. /build/src/Storages/StorageDistributed.cpp:1559: DB::StorageDistributed::getOptimizedCluster(std::shared_ptr, std::shared_ptr const&, DB::SelectQueryInfo const&, std::shared_ptr const&) const @ 0x0000000015d6083b 5. /build/src/Storages/StorageDistributed.cpp:457: DB::StorageDistributed::getQueryProcessingStage(std::shared_ptr, DB::QueryProcessingStage::Enum, std::shared_ptr const&, DB::SelectQueryInfo&) const @ 0x0000000015d5f50d 6. /build/src/Planner/PlannerJoinTree.cpp:921: DB::(anonymous namespace)::buildQueryPlanForTableExpression(std::shared_ptr, std::shared_ptr const&, DB::SelectQueryInfo const&, DB::SelectQueryOptions const&, std::shared_ptr&, bool, bool) @ 0x0000000014996f1b 7. /build/src/Planner/PlannerJoinTree.cpp:2252: DB::buildJoinTreeQueryPlan(std::shared_ptr const&, DB::SelectQueryInfo const&, DB::SelectQueryOptions&, std::unordered_set, std::equal_to, std::allocator> const&, std::shared_ptr&) @ 0x000000001498e109 8. /build/src/Planner/Planner.cpp:1553: DB::Planner::buildPlanForQueryNode() @ 0x0000000014979dae 9. /build/src/Planner/Planner.cpp:1308: DB::Planner::buildQueryPlanIfNeeded() @ 0x000000001497685c 10. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:255: DB::InterpreterSelectQueryAnalyzer::getQueryPlan() @ 0x000000001497476d 11. /build/src/Interpreters/executeQuery.cpp:1405: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88806 12. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 13. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 14. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 15. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 16. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 17. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 18. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 19. ? @ 0x00007fbc6213eac3 20. ? @ 0x00007fbc621d0850 2025.07.28 11:56:41.480337 [ 3287 ] {ae290fd2-9e52-4a7a-90a9-fb33459f2013} executeQuery: Code: 507. DB::Exception: Sharding key modulo(key, 2) is not used. (UNABLE_TO_SKIP_UNUSED_SHARDS) (version 25.3.6.10636.altinitytest (altinity build)) (from [::1]:56432) (comment: 01072_optimize_skip_unused_shards_const_expr_eval.sql) (query 15, line 20) (in query: select * from dist_01072 where key=toInt32(value);), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000a9b78ab 4. /build/src/Storages/StorageDistributed.cpp:1559: DB::StorageDistributed::getOptimizedCluster(std::shared_ptr, std::shared_ptr const&, DB::SelectQueryInfo const&, std::shared_ptr const&) const @ 0x0000000015d6083b 5. /build/src/Storages/StorageDistributed.cpp:457: DB::StorageDistributed::getQueryProcessingStage(std::shared_ptr, DB::QueryProcessingStage::Enum, std::shared_ptr const&, DB::SelectQueryInfo&) const @ 0x0000000015d5f50d 6. /build/src/Planner/PlannerJoinTree.cpp:921: DB::(anonymous namespace)::buildQueryPlanForTableExpression(std::shared_ptr, std::shared_ptr const&, DB::SelectQueryInfo const&, DB::SelectQueryOptions const&, std::shared_ptr&, bool, bool) @ 0x0000000014996f1b 7. /build/src/Planner/PlannerJoinTree.cpp:2252: DB::buildJoinTreeQueryPlan(std::shared_ptr const&, DB::SelectQueryInfo const&, DB::SelectQueryOptions&, std::unordered_set, std::equal_to, std::allocator> const&, std::shared_ptr&) @ 0x000000001498e109 8. /build/src/Planner/Planner.cpp:1553: DB::Planner::buildPlanForQueryNode() @ 0x0000000014979dae 9. /build/src/Planner/Planner.cpp:1308: DB::Planner::buildQueryPlanIfNeeded() @ 0x000000001497685c 10. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:255: DB::InterpreterSelectQueryAnalyzer::getQueryPlan() @ 0x000000001497476d 11. /build/src/Interpreters/executeQuery.cpp:1405: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88806 12. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 13. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 14. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 15. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 16. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 17. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 18. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 19. ? @ 0x00007fbc6213eac3 20. ? @ 0x00007fbc621d0850 2025.07.28 11:56:41.492162 [ 3287 ] {} TCPHandler: Code: 507. DB::Exception: Sharding key modulo(key, 2) is not used. (UNABLE_TO_SKIP_UNUSED_SHARDS), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000a9b78ab 4. /build/src/Storages/StorageDistributed.cpp:1559: DB::StorageDistributed::getOptimizedCluster(std::shared_ptr, std::shared_ptr const&, DB::SelectQueryInfo const&, std::shared_ptr const&) const @ 0x0000000015d6083b 5. /build/src/Storages/StorageDistributed.cpp:457: DB::StorageDistributed::getQueryProcessingStage(std::shared_ptr, DB::QueryProcessingStage::Enum, std::shared_ptr const&, DB::SelectQueryInfo&) const @ 0x0000000015d5f50d 6. /build/src/Planner/PlannerJoinTree.cpp:921: DB::(anonymous namespace)::buildQueryPlanForTableExpression(std::shared_ptr, std::shared_ptr const&, DB::SelectQueryInfo const&, DB::SelectQueryOptions const&, std::shared_ptr&, bool, bool) @ 0x0000000014996f1b 7. /build/src/Planner/PlannerJoinTree.cpp:2252: DB::buildJoinTreeQueryPlan(std::shared_ptr const&, DB::SelectQueryInfo const&, DB::SelectQueryOptions&, std::unordered_set, std::equal_to, std::allocator> const&, std::shared_ptr&) @ 0x000000001498e109 8. /build/src/Planner/Planner.cpp:1553: DB::Planner::buildPlanForQueryNode() @ 0x0000000014979dae 9. /build/src/Planner/Planner.cpp:1308: DB::Planner::buildQueryPlanIfNeeded() @ 0x000000001497685c 10. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:255: DB::InterpreterSelectQueryAnalyzer::getQueryPlan() @ 0x000000001497476d 11. /build/src/Interpreters/executeQuery.cpp:1405: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88806 12. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 13. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 14. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 15. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 16. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 17. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 18. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 19. ? @ 0x00007fbc6213eac3 20. ? @ 0x00007fbc621d0850 2025.07.28 11:56:42.347132 [ 3972 ] {} test_13.rmt2 (7f9b740d-015c-470e-8cc6-8ba33be0dc63): auto DB::StorageReplicatedMergeTree::processQueueEntry(ReplicatedMergeTreeQueue::SelectedEntryPtr)::(anonymous class)::operator()(LogEntryPtr &) const: Code: 86. DB::HTTPException: Received error from remote server http://146b4357c08d:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Ftest%2F01165%2Ftest_13%2Frmt%2Freplicas%2F1&part=20250728_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.6.10636.altinitytest (altinity build)) '. (RECEIVED_ERROR_FROM_REMOTE_IO_SERVER), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.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 const&, int&&, String const&, unsigned long&&, String const&) @ 0x000000000feda8d9 4. /build/src/IO/HTTPCommon.cpp:104: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x000000000feda6e2 5. /build/src/IO/HTTPCommon.cpp:93: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x000000000feda537 6. /build/src/IO/ReadWriteBufferFromHTTP.cpp:277: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x000000001184a4c4 7. /build/src/IO/ReadWriteBufferFromHTTP.cpp:285: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x000000001184a615 8. /build/src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x000000001184ae59 9. /build/src/IO/ReadWriteBufferFromHTTP.cpp:472: void std::__function::__policy_invoker::__call_impl[abi:se190107]>(std::__function::__policy_storage const*) @ 0x000000001184cedd 10. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001184858b 11. /build/src/IO/ReadWriteBufferFromHTTP.cpp:465: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x000000001184bf0b 12. /build/src/IO/ReadBuffer.h:60: DB::ReadBuffer::next() @ 0x000000000a148c7b 13. /build/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) @ 0x0000000011849fb2 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]>&)>&, 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&) @ 0x0000000011841980 15. /build/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) @ 0x000000001621208e 16. /build/src/Storages/StorageReplicatedMergeTree.cpp:5228: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl[abi:se190107] const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000015f9a5fe 17. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000015ed8bfd 18. /build/src/Storages/StorageReplicatedMergeTree.cpp:2514: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x0000000015ec9aab 19. /build/src/Storages/StorageReplicatedMergeTree.cpp:2349: DB::StorageReplicatedMergeTree::executeLogEntry(DB::ReplicatedMergeTreeLogEntry&) @ 0x0000000015eba91b 20. /build/src/Storages/StorageReplicatedMergeTree.cpp:3876: bool std::__function::__policy_invoker&)>::__call_impl[abi:se190107])::$_1, bool (std::shared_ptr&)>>(std::__function::__policy_storage const*, std::shared_ptr&) @ 0x0000000015f9837e 21. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000165d6fc3 22. /build/src/Storages/StorageReplicatedMergeTree.cpp:3872: DB::StorageReplicatedMergeTree::processQueueEntry(std::shared_ptr) @ 0x0000000015efc18a 23. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001624c1b2 24. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000162f9c70 25. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x00000000162fa55a 26. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc6653 27. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000000fccc4c3 28. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc3d92 29. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fcca080 30. ? @ 0x00007fbc6213eac3 31. ? @ 0x00007fbc621d0850 (version 25.3.6.10636.altinitytest (altinity build)) 2025.07.28 11:56:42.643194 [ 3287 ] {a4a27ed9-903d-4349-a73f-5ecf7cb7257a} executeQuery: Code: 507. DB::Exception: Sharding key modulo(key, 2) is not used. (UNABLE_TO_SKIP_UNUSED_SHARDS) (version 25.3.6.10636.altinitytest (altinity build)) (from [::1]:56432) (comment: 01072_optimize_skip_unused_shards_const_expr_eval.sql) (query 21, line 27) (in query: select * from dist_01072 where key=value;), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000a9b78ab 4. /build/src/Storages/StorageDistributed.cpp:1559: DB::StorageDistributed::getOptimizedCluster(std::shared_ptr, std::shared_ptr const&, DB::SelectQueryInfo const&, std::shared_ptr const&) const @ 0x0000000015d6083b 5. /build/src/Storages/StorageDistributed.cpp:457: DB::StorageDistributed::getQueryProcessingStage(std::shared_ptr, DB::QueryProcessingStage::Enum, std::shared_ptr const&, DB::SelectQueryInfo&) const @ 0x0000000015d5f50d 6. /build/src/Planner/PlannerJoinTree.cpp:921: DB::(anonymous namespace)::buildQueryPlanForTableExpression(std::shared_ptr, std::shared_ptr const&, DB::SelectQueryInfo const&, DB::SelectQueryOptions const&, std::shared_ptr&, bool, bool) @ 0x0000000014996f1b 7. /build/src/Planner/PlannerJoinTree.cpp:2252: DB::buildJoinTreeQueryPlan(std::shared_ptr const&, DB::SelectQueryInfo const&, DB::SelectQueryOptions&, std::unordered_set, std::equal_to, std::allocator> const&, std::shared_ptr&) @ 0x000000001498e109 8. /build/src/Planner/Planner.cpp:1553: DB::Planner::buildPlanForQueryNode() @ 0x0000000014979dae 9. /build/src/Planner/Planner.cpp:1308: DB::Planner::buildQueryPlanIfNeeded() @ 0x000000001497685c 10. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:255: DB::InterpreterSelectQueryAnalyzer::getQueryPlan() @ 0x000000001497476d 11. /build/src/Interpreters/executeQuery.cpp:1405: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88806 12. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 13. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 14. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 15. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 16. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 17. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 18. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 19. ? @ 0x00007fbc6213eac3 20. ? @ 0x00007fbc621d0850 2025.07.28 11:56:42.645870 [ 3287 ] {} TCPHandler: Code: 507. DB::Exception: Sharding key modulo(key, 2) is not used. (UNABLE_TO_SKIP_UNUSED_SHARDS), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000a9b78ab 4. /build/src/Storages/StorageDistributed.cpp:1559: DB::StorageDistributed::getOptimizedCluster(std::shared_ptr, std::shared_ptr const&, DB::SelectQueryInfo const&, std::shared_ptr const&) const @ 0x0000000015d6083b 5. /build/src/Storages/StorageDistributed.cpp:457: DB::StorageDistributed::getQueryProcessingStage(std::shared_ptr, DB::QueryProcessingStage::Enum, std::shared_ptr const&, DB::SelectQueryInfo&) const @ 0x0000000015d5f50d 6. /build/src/Planner/PlannerJoinTree.cpp:921: DB::(anonymous namespace)::buildQueryPlanForTableExpression(std::shared_ptr, std::shared_ptr const&, DB::SelectQueryInfo const&, DB::SelectQueryOptions const&, std::shared_ptr&, bool, bool) @ 0x0000000014996f1b 7. /build/src/Planner/PlannerJoinTree.cpp:2252: DB::buildJoinTreeQueryPlan(std::shared_ptr const&, DB::SelectQueryInfo const&, DB::SelectQueryOptions&, std::unordered_set, std::equal_to, std::allocator> const&, std::shared_ptr&) @ 0x000000001498e109 8. /build/src/Planner/Planner.cpp:1553: DB::Planner::buildPlanForQueryNode() @ 0x0000000014979dae 9. /build/src/Planner/Planner.cpp:1308: DB::Planner::buildQueryPlanIfNeeded() @ 0x000000001497685c 10. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:255: DB::InterpreterSelectQueryAnalyzer::getQueryPlan() @ 0x000000001497476d 11. /build/src/Interpreters/executeQuery.cpp:1405: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88806 12. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 13. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 14. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 15. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 16. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 17. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 18. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 19. ? @ 0x00007fbc6213eac3 20. ? @ 0x00007fbc621d0850 2025.07.28 11:56:42.675041 [ 3287 ] {09f6bb03-333a-4d70-add1-77eaa2d7b7dc} executeQuery: Code: 507. DB::Exception: Sharding key modulo(key, 2) is not used. (UNABLE_TO_SKIP_UNUSED_SHARDS) (version 25.3.6.10636.altinitytest (altinity build)) (from [::1]:56432) (comment: 01072_optimize_skip_unused_shards_const_expr_eval.sql) (query 22, line 28) (in query: select * from dist_01072 where key=toInt32(value);), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000a9b78ab 4. /build/src/Storages/StorageDistributed.cpp:1559: DB::StorageDistributed::getOptimizedCluster(std::shared_ptr, std::shared_ptr const&, DB::SelectQueryInfo const&, std::shared_ptr const&) const @ 0x0000000015d6083b 5. /build/src/Storages/StorageDistributed.cpp:457: DB::StorageDistributed::getQueryProcessingStage(std::shared_ptr, DB::QueryProcessingStage::Enum, std::shared_ptr const&, DB::SelectQueryInfo&) const @ 0x0000000015d5f50d 6. /build/src/Planner/PlannerJoinTree.cpp:921: DB::(anonymous namespace)::buildQueryPlanForTableExpression(std::shared_ptr, std::shared_ptr const&, DB::SelectQueryInfo const&, DB::SelectQueryOptions const&, std::shared_ptr&, bool, bool) @ 0x0000000014996f1b 7. /build/src/Planner/PlannerJoinTree.cpp:2252: DB::buildJoinTreeQueryPlan(std::shared_ptr const&, DB::SelectQueryInfo const&, DB::SelectQueryOptions&, std::unordered_set, std::equal_to, std::allocator> const&, std::shared_ptr&) @ 0x000000001498e109 8. /build/src/Planner/Planner.cpp:1553: DB::Planner::buildPlanForQueryNode() @ 0x0000000014979dae 9. /build/src/Planner/Planner.cpp:1308: DB::Planner::buildQueryPlanIfNeeded() @ 0x000000001497685c 10. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:255: DB::InterpreterSelectQueryAnalyzer::getQueryPlan() @ 0x000000001497476d 11. /build/src/Interpreters/executeQuery.cpp:1405: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88806 12. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 13. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 14. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 15. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 16. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 17. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 18. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 19. ? @ 0x00007fbc6213eac3 20. ? @ 0x00007fbc621d0850 2025.07.28 11:56:42.677454 [ 3287 ] {} TCPHandler: Code: 507. DB::Exception: Sharding key modulo(key, 2) is not used. (UNABLE_TO_SKIP_UNUSED_SHARDS), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000a9b78ab 4. /build/src/Storages/StorageDistributed.cpp:1559: DB::StorageDistributed::getOptimizedCluster(std::shared_ptr, std::shared_ptr const&, DB::SelectQueryInfo const&, std::shared_ptr const&) const @ 0x0000000015d6083b 5. /build/src/Storages/StorageDistributed.cpp:457: DB::StorageDistributed::getQueryProcessingStage(std::shared_ptr, DB::QueryProcessingStage::Enum, std::shared_ptr const&, DB::SelectQueryInfo&) const @ 0x0000000015d5f50d 6. /build/src/Planner/PlannerJoinTree.cpp:921: DB::(anonymous namespace)::buildQueryPlanForTableExpression(std::shared_ptr, std::shared_ptr const&, DB::SelectQueryInfo const&, DB::SelectQueryOptions const&, std::shared_ptr&, bool, bool) @ 0x0000000014996f1b 7. /build/src/Planner/PlannerJoinTree.cpp:2252: DB::buildJoinTreeQueryPlan(std::shared_ptr const&, DB::SelectQueryInfo const&, DB::SelectQueryOptions&, std::unordered_set, std::equal_to, std::allocator> const&, std::shared_ptr&) @ 0x000000001498e109 8. /build/src/Planner/Planner.cpp:1553: DB::Planner::buildPlanForQueryNode() @ 0x0000000014979dae 9. /build/src/Planner/Planner.cpp:1308: DB::Planner::buildQueryPlanIfNeeded() @ 0x000000001497685c 10. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:255: DB::InterpreterSelectQueryAnalyzer::getQueryPlan() @ 0x000000001497476d 11. /build/src/Interpreters/executeQuery.cpp:1405: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88806 12. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 13. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 14. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 15. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 16. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 17. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 18. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 19. ? @ 0x00007fbc6213eac3 20. ? @ 0x00007fbc621d0850 2025.07.28 11:56:43.293878 [ 3963 ] {} test_13.rmt2 (7f9b740d-015c-470e-8cc6-8ba33be0dc63): auto DB::StorageReplicatedMergeTree::processQueueEntry(ReplicatedMergeTreeQueue::SelectedEntryPtr)::(anonymous class)::operator()(LogEntryPtr &) const: Code: 86. DB::HTTPException: Received error from remote server http://146b4357c08d:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Ftest%2F01165%2Ftest_13%2Frmt%2Freplicas%2F1&part=20250728_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.6.10636.altinitytest (altinity build)) '. (RECEIVED_ERROR_FROM_REMOTE_IO_SERVER), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.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 const&, int&&, String const&, unsigned long&&, String const&) @ 0x000000000feda8d9 4. /build/src/IO/HTTPCommon.cpp:104: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x000000000feda6e2 5. /build/src/IO/HTTPCommon.cpp:93: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x000000000feda537 6. /build/src/IO/ReadWriteBufferFromHTTP.cpp:277: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x000000001184a4c4 7. /build/src/IO/ReadWriteBufferFromHTTP.cpp:285: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x000000001184a615 8. /build/src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x000000001184ae59 9. /build/src/IO/ReadWriteBufferFromHTTP.cpp:472: void std::__function::__policy_invoker::__call_impl[abi:se190107]>(std::__function::__policy_storage const*) @ 0x000000001184cedd 10. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001184858b 11. /build/src/IO/ReadWriteBufferFromHTTP.cpp:465: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x000000001184bf0b 12. /build/src/IO/ReadBuffer.h:60: DB::ReadBuffer::next() @ 0x000000000a148c7b 13. /build/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) @ 0x0000000011849fb2 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]>&)>&, 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&) @ 0x0000000011841980 15. /build/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) @ 0x000000001621208e 16. /build/src/Storages/StorageReplicatedMergeTree.cpp:5228: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl[abi:se190107] const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000015f9a5fe 17. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000015ed8bfd 18. /build/src/Storages/StorageReplicatedMergeTree.cpp:2514: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x0000000015ec9aab 19. /build/src/Storages/StorageReplicatedMergeTree.cpp:2349: DB::StorageReplicatedMergeTree::executeLogEntry(DB::ReplicatedMergeTreeLogEntry&) @ 0x0000000015eba91b 20. /build/src/Storages/StorageReplicatedMergeTree.cpp:3876: bool std::__function::__policy_invoker&)>::__call_impl[abi:se190107])::$_1, bool (std::shared_ptr&)>>(std::__function::__policy_storage const*, std::shared_ptr&) @ 0x0000000015f9837e 21. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000165d6fc3 22. /build/src/Storages/StorageReplicatedMergeTree.cpp:3872: DB::StorageReplicatedMergeTree::processQueueEntry(std::shared_ptr) @ 0x0000000015efc18a 23. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001624c1b2 24. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000162f9c70 25. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x00000000162fa55a 26. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc6653 27. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000000fccc4c3 28. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc3d92 29. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fcca080 30. ? @ 0x00007fbc6213eac3 31. ? @ 0x00007fbc621d0850 (version 25.3.6.10636.altinitytest (altinity build)) 2025.07.28 11:56:43.622536 [ 3287 ] {b7e75f86-074c-4671-a96e-2f6251811790} executeQuery: Code: 507. DB::Exception: Sharding key modulo(key, 2) is not used. (UNABLE_TO_SKIP_UNUSED_SHARDS) (version 25.3.6.10636.altinitytest (altinity build)) (from [::1]:56432) (comment: 01072_optimize_skip_unused_shards_const_expr_eval.sql) (query 29, line 37) (in query: select * from dist_01072 where key=value;), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000a9b78ab 4. /build/src/Storages/StorageDistributed.cpp:1559: DB::StorageDistributed::getOptimizedCluster(std::shared_ptr, std::shared_ptr const&, DB::SelectQueryInfo const&, std::shared_ptr const&) const @ 0x0000000015d6083b 5. /build/src/Storages/StorageDistributed.cpp:457: DB::StorageDistributed::getQueryProcessingStage(std::shared_ptr, DB::QueryProcessingStage::Enum, std::shared_ptr const&, DB::SelectQueryInfo&) const @ 0x0000000015d5f50d 6. /build/src/Planner/PlannerJoinTree.cpp:921: DB::(anonymous namespace)::buildQueryPlanForTableExpression(std::shared_ptr, std::shared_ptr const&, DB::SelectQueryInfo const&, DB::SelectQueryOptions const&, std::shared_ptr&, bool, bool) @ 0x0000000014996f1b 7. /build/src/Planner/PlannerJoinTree.cpp:2252: DB::buildJoinTreeQueryPlan(std::shared_ptr const&, DB::SelectQueryInfo const&, DB::SelectQueryOptions&, std::unordered_set, std::equal_to, std::allocator> const&, std::shared_ptr&) @ 0x000000001498e109 8. /build/src/Planner/Planner.cpp:1553: DB::Planner::buildPlanForQueryNode() @ 0x0000000014979dae 9. /build/src/Planner/Planner.cpp:1308: DB::Planner::buildQueryPlanIfNeeded() @ 0x000000001497685c 10. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:255: DB::InterpreterSelectQueryAnalyzer::getQueryPlan() @ 0x000000001497476d 11. /build/src/Interpreters/executeQuery.cpp:1405: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88806 12. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 13. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 14. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 15. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 16. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 17. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 18. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 19. ? @ 0x00007fbc6213eac3 20. ? @ 0x00007fbc621d0850 2025.07.28 11:56:43.625009 [ 3287 ] {} TCPHandler: Code: 507. DB::Exception: Sharding key modulo(key, 2) is not used. (UNABLE_TO_SKIP_UNUSED_SHARDS), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000a9b78ab 4. /build/src/Storages/StorageDistributed.cpp:1559: DB::StorageDistributed::getOptimizedCluster(std::shared_ptr, std::shared_ptr const&, DB::SelectQueryInfo const&, std::shared_ptr const&) const @ 0x0000000015d6083b 5. /build/src/Storages/StorageDistributed.cpp:457: DB::StorageDistributed::getQueryProcessingStage(std::shared_ptr, DB::QueryProcessingStage::Enum, std::shared_ptr const&, DB::SelectQueryInfo&) const @ 0x0000000015d5f50d 6. /build/src/Planner/PlannerJoinTree.cpp:921: DB::(anonymous namespace)::buildQueryPlanForTableExpression(std::shared_ptr, std::shared_ptr const&, DB::SelectQueryInfo const&, DB::SelectQueryOptions const&, std::shared_ptr&, bool, bool) @ 0x0000000014996f1b 7. /build/src/Planner/PlannerJoinTree.cpp:2252: DB::buildJoinTreeQueryPlan(std::shared_ptr const&, DB::SelectQueryInfo const&, DB::SelectQueryOptions&, std::unordered_set, std::equal_to, std::allocator> const&, std::shared_ptr&) @ 0x000000001498e109 8. /build/src/Planner/Planner.cpp:1553: DB::Planner::buildPlanForQueryNode() @ 0x0000000014979dae 9. /build/src/Planner/Planner.cpp:1308: DB::Planner::buildQueryPlanIfNeeded() @ 0x000000001497685c 10. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:255: DB::InterpreterSelectQueryAnalyzer::getQueryPlan() @ 0x000000001497476d 11. /build/src/Interpreters/executeQuery.cpp:1405: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88806 12. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 13. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 14. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 15. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 16. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 17. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 18. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 19. ? @ 0x00007fbc6213eac3 20. ? @ 0x00007fbc621d0850 2025.07.28 11:56:43.682663 [ 3287 ] {9636edfa-01e7-4f80-9613-746d1790a210} executeQuery: Code: 507. DB::Exception: Sharding key modulo(key, 2) is not used. (UNABLE_TO_SKIP_UNUSED_SHARDS) (version 25.3.6.10636.altinitytest (altinity build)) (from [::1]:56432) (comment: 01072_optimize_skip_unused_shards_const_expr_eval.sql) (query 30, line 38) (in query: select * from dist_01072 where key=toInt32(value);), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000a9b78ab 4. /build/src/Storages/StorageDistributed.cpp:1559: DB::StorageDistributed::getOptimizedCluster(std::shared_ptr, std::shared_ptr const&, DB::SelectQueryInfo const&, std::shared_ptr const&) const @ 0x0000000015d6083b 5. /build/src/Storages/StorageDistributed.cpp:457: DB::StorageDistributed::getQueryProcessingStage(std::shared_ptr, DB::QueryProcessingStage::Enum, std::shared_ptr const&, DB::SelectQueryInfo&) const @ 0x0000000015d5f50d 6. /build/src/Planner/PlannerJoinTree.cpp:921: DB::(anonymous namespace)::buildQueryPlanForTableExpression(std::shared_ptr, std::shared_ptr const&, DB::SelectQueryInfo const&, DB::SelectQueryOptions const&, std::shared_ptr&, bool, bool) @ 0x0000000014996f1b 7. /build/src/Planner/PlannerJoinTree.cpp:2252: DB::buildJoinTreeQueryPlan(std::shared_ptr const&, DB::SelectQueryInfo const&, DB::SelectQueryOptions&, std::unordered_set, std::equal_to, std::allocator> const&, std::shared_ptr&) @ 0x000000001498e109 8. /build/src/Planner/Planner.cpp:1553: DB::Planner::buildPlanForQueryNode() @ 0x0000000014979dae 9. /build/src/Planner/Planner.cpp:1308: DB::Planner::buildQueryPlanIfNeeded() @ 0x000000001497685c 10. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:255: DB::InterpreterSelectQueryAnalyzer::getQueryPlan() @ 0x000000001497476d 11. /build/src/Interpreters/executeQuery.cpp:1405: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88806 12. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 13. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 14. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 15. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 16. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 17. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 18. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 19. ? @ 0x00007fbc6213eac3 20. ? @ 0x00007fbc621d0850 2025.07.28 11:56:43.702352 [ 3287 ] {} TCPHandler: Code: 507. DB::Exception: Sharding key modulo(key, 2) is not used. (UNABLE_TO_SKIP_UNUSED_SHARDS), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000a9b78ab 4. /build/src/Storages/StorageDistributed.cpp:1559: DB::StorageDistributed::getOptimizedCluster(std::shared_ptr, std::shared_ptr const&, DB::SelectQueryInfo const&, std::shared_ptr const&) const @ 0x0000000015d6083b 5. /build/src/Storages/StorageDistributed.cpp:457: DB::StorageDistributed::getQueryProcessingStage(std::shared_ptr, DB::QueryProcessingStage::Enum, std::shared_ptr const&, DB::SelectQueryInfo&) const @ 0x0000000015d5f50d 6. /build/src/Planner/PlannerJoinTree.cpp:921: DB::(anonymous namespace)::buildQueryPlanForTableExpression(std::shared_ptr, std::shared_ptr const&, DB::SelectQueryInfo const&, DB::SelectQueryOptions const&, std::shared_ptr&, bool, bool) @ 0x0000000014996f1b 7. /build/src/Planner/PlannerJoinTree.cpp:2252: DB::buildJoinTreeQueryPlan(std::shared_ptr const&, DB::SelectQueryInfo const&, DB::SelectQueryOptions&, std::unordered_set, std::equal_to, std::allocator> const&, std::shared_ptr&) @ 0x000000001498e109 8. /build/src/Planner/Planner.cpp:1553: DB::Planner::buildPlanForQueryNode() @ 0x0000000014979dae 9. /build/src/Planner/Planner.cpp:1308: DB::Planner::buildQueryPlanIfNeeded() @ 0x000000001497685c 10. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:255: DB::InterpreterSelectQueryAnalyzer::getQueryPlan() @ 0x000000001497476d 11. /build/src/Interpreters/executeQuery.cpp:1405: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88806 12. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 13. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 14. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 15. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 16. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 17. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 18. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 19. ? @ 0x00007fbc6213eac3 20. ? @ 0x00007fbc621d0850 2025.07.28 11:56:44.096593 [ 3968 ] {} test_13.rmt2 (7f9b740d-015c-470e-8cc6-8ba33be0dc63): auto DB::StorageReplicatedMergeTree::processQueueEntry(ReplicatedMergeTreeQueue::SelectedEntryPtr)::(anonymous class)::operator()(LogEntryPtr &) const: Code: 86. DB::HTTPException: Received error from remote server http://146b4357c08d:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Ftest%2F01165%2Ftest_13%2Frmt%2Freplicas%2F1&part=20250728_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.6.10636.altinitytest (altinity build)) '. (RECEIVED_ERROR_FROM_REMOTE_IO_SERVER), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.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 const&, int&&, String const&, unsigned long&&, String const&) @ 0x000000000feda8d9 4. /build/src/IO/HTTPCommon.cpp:104: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x000000000feda6e2 5. /build/src/IO/HTTPCommon.cpp:93: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x000000000feda537 6. /build/src/IO/ReadWriteBufferFromHTTP.cpp:277: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x000000001184a4c4 7. /build/src/IO/ReadWriteBufferFromHTTP.cpp:285: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x000000001184a615 8. /build/src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x000000001184ae59 9. /build/src/IO/ReadWriteBufferFromHTTP.cpp:472: void std::__function::__policy_invoker::__call_impl[abi:se190107]>(std::__function::__policy_storage const*) @ 0x000000001184cedd 10. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001184858b 11. /build/src/IO/ReadWriteBufferFromHTTP.cpp:465: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x000000001184bf0b 12. /build/src/IO/ReadBuffer.h:60: DB::ReadBuffer::next() @ 0x000000000a148c7b 13. /build/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) @ 0x0000000011849fb2 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]>&)>&, 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&) @ 0x0000000011841980 15. /build/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) @ 0x000000001621208e 16. /build/src/Storages/StorageReplicatedMergeTree.cpp:5228: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl[abi:se190107] const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000015f9a5fe 17. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000015ed8bfd 18. /build/src/Storages/StorageReplicatedMergeTree.cpp:2514: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x0000000015ec9aab 19. /build/src/Storages/StorageReplicatedMergeTree.cpp:2349: DB::StorageReplicatedMergeTree::executeLogEntry(DB::ReplicatedMergeTreeLogEntry&) @ 0x0000000015eba91b 20. /build/src/Storages/StorageReplicatedMergeTree.cpp:3876: bool std::__function::__policy_invoker&)>::__call_impl[abi:se190107])::$_1, bool (std::shared_ptr&)>>(std::__function::__policy_storage const*, std::shared_ptr&) @ 0x0000000015f9837e 21. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000165d6fc3 22. /build/src/Storages/StorageReplicatedMergeTree.cpp:3872: DB::StorageReplicatedMergeTree::processQueueEntry(std::shared_ptr) @ 0x0000000015efc18a 23. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001624c1b2 24. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000162f9c70 25. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x00000000162fa55a 26. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc6653 27. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000000fccc4c3 28. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc3d92 29. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fcca080 30. ? @ 0x00007fbc6213eac3 31. ? @ 0x00007fbc621d0850 (version 25.3.6.10636.altinitytest (altinity build)) 2025.07.28 11:56:44.458287 [ 3969 ] {} test_13.rmt2 (7f9b740d-015c-470e-8cc6-8ba33be0dc63): auto DB::StorageReplicatedMergeTree::processQueueEntry(ReplicatedMergeTreeQueue::SelectedEntryPtr)::(anonymous class)::operator()(LogEntryPtr &) const: Code: 86. DB::HTTPException: Received error from remote server http://146b4357c08d:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Ftest%2F01165%2Ftest_13%2Frmt%2Freplicas%2F1&part=20250728_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.6.10636.altinitytest (altinity build)) '. (RECEIVED_ERROR_FROM_REMOTE_IO_SERVER), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.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 const&, int&&, String const&, unsigned long&&, String const&) @ 0x000000000feda8d9 4. /build/src/IO/HTTPCommon.cpp:104: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x000000000feda6e2 5. /build/src/IO/HTTPCommon.cpp:93: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x000000000feda537 6. /build/src/IO/ReadWriteBufferFromHTTP.cpp:277: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x000000001184a4c4 7. /build/src/IO/ReadWriteBufferFromHTTP.cpp:285: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x000000001184a615 8. /build/src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x000000001184ae59 9. /build/src/IO/ReadWriteBufferFromHTTP.cpp:472: void std::__function::__policy_invoker::__call_impl[abi:se190107]>(std::__function::__policy_storage const*) @ 0x000000001184cedd 10. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001184858b 11. /build/src/IO/ReadWriteBufferFromHTTP.cpp:465: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x000000001184bf0b 12. /build/src/IO/ReadBuffer.h:60: DB::ReadBuffer::next() @ 0x000000000a148c7b 13. /build/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) @ 0x0000000011849fb2 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]>&)>&, 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&) @ 0x0000000011841980 15. /build/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) @ 0x000000001621208e 16. /build/src/Storages/StorageReplicatedMergeTree.cpp:5228: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl[abi:se190107] const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000015f9a5fe 17. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000015ed8bfd 18. /build/src/Storages/StorageReplicatedMergeTree.cpp:2514: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x0000000015ec9aab 19. /build/src/Storages/StorageReplicatedMergeTree.cpp:2349: DB::StorageReplicatedMergeTree::executeLogEntry(DB::ReplicatedMergeTreeLogEntry&) @ 0x0000000015eba91b 20. /build/src/Storages/StorageReplicatedMergeTree.cpp:3876: bool std::__function::__policy_invoker&)>::__call_impl[abi:se190107])::$_1, bool (std::shared_ptr&)>>(std::__function::__policy_storage const*, std::shared_ptr&) @ 0x0000000015f9837e 21. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000165d6fc3 22. /build/src/Storages/StorageReplicatedMergeTree.cpp:3872: DB::StorageReplicatedMergeTree::processQueueEntry(std::shared_ptr) @ 0x0000000015efc18a 23. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001624c1b2 24. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000162f9c70 25. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x00000000162fa55a 26. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc6653 27. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000000fccc4c3 28. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc3d92 29. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fcca080 30. ? @ 0x00007fbc6213eac3 31. ? @ 0x00007fbc621d0850 (version 25.3.6.10636.altinitytest (altinity build)) 2025.07.28 11:56:44.829798 [ 3287 ] {860aecab-b548-45eb-8e99-4502b8168dea} executeQuery: Code: 507. DB::Exception: Sharding key modulo(key, 2) is not used. (UNABLE_TO_SKIP_UNUSED_SHARDS) (version 25.3.6.10636.altinitytest (altinity build)) (from [::1]:56432) (comment: 01072_optimize_skip_unused_shards_const_expr_eval.sql) (query 36, line 45) (in query: select * from dist_01072 where key=value;), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000a9b78ab 4. /build/src/Storages/StorageDistributed.cpp:1559: DB::StorageDistributed::getOptimizedCluster(std::shared_ptr, std::shared_ptr const&, DB::SelectQueryInfo const&, std::shared_ptr const&) const @ 0x0000000015d6083b 5. /build/src/Storages/StorageDistributed.cpp:457: DB::StorageDistributed::getQueryProcessingStage(std::shared_ptr, DB::QueryProcessingStage::Enum, std::shared_ptr const&, DB::SelectQueryInfo&) const @ 0x0000000015d5f50d 6. /build/src/Planner/PlannerJoinTree.cpp:921: DB::(anonymous namespace)::buildQueryPlanForTableExpression(std::shared_ptr, std::shared_ptr const&, DB::SelectQueryInfo const&, DB::SelectQueryOptions const&, std::shared_ptr&, bool, bool) @ 0x0000000014996f1b 7. /build/src/Planner/PlannerJoinTree.cpp:2252: DB::buildJoinTreeQueryPlan(std::shared_ptr const&, DB::SelectQueryInfo const&, DB::SelectQueryOptions&, std::unordered_set, std::equal_to, std::allocator> const&, std::shared_ptr&) @ 0x000000001498e109 8. /build/src/Planner/Planner.cpp:1553: DB::Planner::buildPlanForQueryNode() @ 0x0000000014979dae 9. /build/src/Planner/Planner.cpp:1308: DB::Planner::buildQueryPlanIfNeeded() @ 0x000000001497685c 10. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:255: DB::InterpreterSelectQueryAnalyzer::getQueryPlan() @ 0x000000001497476d 11. /build/src/Interpreters/executeQuery.cpp:1405: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88806 12. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 13. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 14. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 15. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 16. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 17. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 18. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 19. ? @ 0x00007fbc6213eac3 20. ? @ 0x00007fbc621d0850 2025.07.28 11:56:44.831790 [ 3287 ] {} TCPHandler: Code: 507. DB::Exception: Sharding key modulo(key, 2) is not used. (UNABLE_TO_SKIP_UNUSED_SHARDS), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000a9b78ab 4. /build/src/Storages/StorageDistributed.cpp:1559: DB::StorageDistributed::getOptimizedCluster(std::shared_ptr, std::shared_ptr const&, DB::SelectQueryInfo const&, std::shared_ptr const&) const @ 0x0000000015d6083b 5. /build/src/Storages/StorageDistributed.cpp:457: DB::StorageDistributed::getQueryProcessingStage(std::shared_ptr, DB::QueryProcessingStage::Enum, std::shared_ptr const&, DB::SelectQueryInfo&) const @ 0x0000000015d5f50d 6. /build/src/Planner/PlannerJoinTree.cpp:921: DB::(anonymous namespace)::buildQueryPlanForTableExpression(std::shared_ptr, std::shared_ptr const&, DB::SelectQueryInfo const&, DB::SelectQueryOptions const&, std::shared_ptr&, bool, bool) @ 0x0000000014996f1b 7. /build/src/Planner/PlannerJoinTree.cpp:2252: DB::buildJoinTreeQueryPlan(std::shared_ptr const&, DB::SelectQueryInfo const&, DB::SelectQueryOptions&, std::unordered_set, std::equal_to, std::allocator> const&, std::shared_ptr&) @ 0x000000001498e109 8. /build/src/Planner/Planner.cpp:1553: DB::Planner::buildPlanForQueryNode() @ 0x0000000014979dae 9. /build/src/Planner/Planner.cpp:1308: DB::Planner::buildQueryPlanIfNeeded() @ 0x000000001497685c 10. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:255: DB::InterpreterSelectQueryAnalyzer::getQueryPlan() @ 0x000000001497476d 11. /build/src/Interpreters/executeQuery.cpp:1405: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88806 12. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 13. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 14. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 15. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 16. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 17. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 18. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 19. ? @ 0x00007fbc6213eac3 20. ? @ 0x00007fbc621d0850 2025.07.28 11:56:44.860673 [ 3287 ] {3c8f8fc0-b481-4d2f-8a25-1e27ca4e000e} executeQuery: Code: 507. DB::Exception: Sharding key modulo(key, 2) is not used. (UNABLE_TO_SKIP_UNUSED_SHARDS) (version 25.3.6.10636.altinitytest (altinity build)) (from [::1]:56432) (comment: 01072_optimize_skip_unused_shards_const_expr_eval.sql) (query 37, line 46) (in query: select * from dist_01072 where key=toInt32(value);), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000a9b78ab 4. /build/src/Storages/StorageDistributed.cpp:1559: DB::StorageDistributed::getOptimizedCluster(std::shared_ptr, std::shared_ptr const&, DB::SelectQueryInfo const&, std::shared_ptr const&) const @ 0x0000000015d6083b 5. /build/src/Storages/StorageDistributed.cpp:457: DB::StorageDistributed::getQueryProcessingStage(std::shared_ptr, DB::QueryProcessingStage::Enum, std::shared_ptr const&, DB::SelectQueryInfo&) const @ 0x0000000015d5f50d 6. /build/src/Planner/PlannerJoinTree.cpp:921: DB::(anonymous namespace)::buildQueryPlanForTableExpression(std::shared_ptr, std::shared_ptr const&, DB::SelectQueryInfo const&, DB::SelectQueryOptions const&, std::shared_ptr&, bool, bool) @ 0x0000000014996f1b 7. /build/src/Planner/PlannerJoinTree.cpp:2252: DB::buildJoinTreeQueryPlan(std::shared_ptr const&, DB::SelectQueryInfo const&, DB::SelectQueryOptions&, std::unordered_set, std::equal_to, std::allocator> const&, std::shared_ptr&) @ 0x000000001498e109 8. /build/src/Planner/Planner.cpp:1553: DB::Planner::buildPlanForQueryNode() @ 0x0000000014979dae 9. /build/src/Planner/Planner.cpp:1308: DB::Planner::buildQueryPlanIfNeeded() @ 0x000000001497685c 10. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:255: DB::InterpreterSelectQueryAnalyzer::getQueryPlan() @ 0x000000001497476d 11. /build/src/Interpreters/executeQuery.cpp:1405: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88806 12. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 13. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 14. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 15. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 16. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 17. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 18. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 19. ? @ 0x00007fbc6213eac3 20. ? @ 0x00007fbc621d0850 2025.07.28 11:56:44.863185 [ 3287 ] {} TCPHandler: Code: 507. DB::Exception: Sharding key modulo(key, 2) is not used. (UNABLE_TO_SKIP_UNUSED_SHARDS), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000a9b78ab 4. /build/src/Storages/StorageDistributed.cpp:1559: DB::StorageDistributed::getOptimizedCluster(std::shared_ptr, std::shared_ptr const&, DB::SelectQueryInfo const&, std::shared_ptr const&) const @ 0x0000000015d6083b 5. /build/src/Storages/StorageDistributed.cpp:457: DB::StorageDistributed::getQueryProcessingStage(std::shared_ptr, DB::QueryProcessingStage::Enum, std::shared_ptr const&, DB::SelectQueryInfo&) const @ 0x0000000015d5f50d 6. /build/src/Planner/PlannerJoinTree.cpp:921: DB::(anonymous namespace)::buildQueryPlanForTableExpression(std::shared_ptr, std::shared_ptr const&, DB::SelectQueryInfo const&, DB::SelectQueryOptions const&, std::shared_ptr&, bool, bool) @ 0x0000000014996f1b 7. /build/src/Planner/PlannerJoinTree.cpp:2252: DB::buildJoinTreeQueryPlan(std::shared_ptr const&, DB::SelectQueryInfo const&, DB::SelectQueryOptions&, std::unordered_set, std::equal_to, std::allocator> const&, std::shared_ptr&) @ 0x000000001498e109 8. /build/src/Planner/Planner.cpp:1553: DB::Planner::buildPlanForQueryNode() @ 0x0000000014979dae 9. /build/src/Planner/Planner.cpp:1308: DB::Planner::buildQueryPlanIfNeeded() @ 0x000000001497685c 10. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:255: DB::InterpreterSelectQueryAnalyzer::getQueryPlan() @ 0x000000001497476d 11. /build/src/Interpreters/executeQuery.cpp:1405: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88806 12. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 13. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 14. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 15. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 16. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 17. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 18. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 19. ? @ 0x00007fbc6213eac3 20. ? @ 0x00007fbc621d0850 2025.07.28 11:56:44.885032 [ 3965 ] {} test_13.rmt2 (7f9b740d-015c-470e-8cc6-8ba33be0dc63): auto DB::StorageReplicatedMergeTree::processQueueEntry(ReplicatedMergeTreeQueue::SelectedEntryPtr)::(anonymous class)::operator()(LogEntryPtr &) const: Code: 86. DB::HTTPException: Received error from remote server http://146b4357c08d:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Ftest%2F01165%2Ftest_13%2Frmt%2Freplicas%2F1&part=20250728_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.6.10636.altinitytest (altinity build)) '. (RECEIVED_ERROR_FROM_REMOTE_IO_SERVER), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.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 const&, int&&, String const&, unsigned long&&, String const&) @ 0x000000000feda8d9 4. /build/src/IO/HTTPCommon.cpp:104: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x000000000feda6e2 5. /build/src/IO/HTTPCommon.cpp:93: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x000000000feda537 6. /build/src/IO/ReadWriteBufferFromHTTP.cpp:277: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x000000001184a4c4 7. /build/src/IO/ReadWriteBufferFromHTTP.cpp:285: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x000000001184a615 8. /build/src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x000000001184ae59 9. /build/src/IO/ReadWriteBufferFromHTTP.cpp:472: void std::__function::__policy_invoker::__call_impl[abi:se190107]>(std::__function::__policy_storage const*) @ 0x000000001184cedd 10. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001184858b 11. /build/src/IO/ReadWriteBufferFromHTTP.cpp:465: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x000000001184bf0b 12. /build/src/IO/ReadBuffer.h:60: DB::ReadBuffer::next() @ 0x000000000a148c7b 13. /build/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) @ 0x0000000011849fb2 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]>&)>&, 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&) @ 0x0000000011841980 15. /build/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) @ 0x000000001621208e 16. /build/src/Storages/StorageReplicatedMergeTree.cpp:5228: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl[abi:se190107] const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000015f9a5fe 17. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000015ed8bfd 18. /build/src/Storages/StorageReplicatedMergeTree.cpp:2514: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x0000000015ec9aab 19. /build/src/Storages/StorageReplicatedMergeTree.cpp:2349: DB::StorageReplicatedMergeTree::executeLogEntry(DB::ReplicatedMergeTreeLogEntry&) @ 0x0000000015eba91b 20. /build/src/Storages/StorageReplicatedMergeTree.cpp:3876: bool std::__function::__policy_invoker&)>::__call_impl[abi:se190107])::$_1, bool (std::shared_ptr&)>>(std::__function::__policy_storage const*, std::shared_ptr&) @ 0x0000000015f9837e 21. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000165d6fc3 22. /build/src/Storages/StorageReplicatedMergeTree.cpp:3872: DB::StorageReplicatedMergeTree::processQueueEntry(std::shared_ptr) @ 0x0000000015efc18a 23. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001624c1b2 24. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000162f9c70 25. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x00000000162fa55a 26. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc6653 27. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000000fccc4c3 28. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc3d92 29. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fcca080 30. ? @ 0x00007fbc6213eac3 31. ? @ 0x00007fbc621d0850 (version 25.3.6.10636.altinitytest (altinity build)) 2025.07.28 11:56:45.118547 [ 3287 ] {1120dd29-1858-46bf-88ae-edfd4a2185ff} executeQuery: Code: 48. DB::Exception: Truncate is not supported by storage Null. (NOT_IMPLEMENTED) (version 25.3.6.10636.altinitytest (altinity build)) (from 0.0.0.0:0) (comment: 01072_optimize_skip_unused_shards_const_expr_eval.sql) (in query: /* ddl_entry=query-0000000010 */ TRUNCATE TABLE test_2k34u9qu.data_01072), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x000000000a06b56b 4. /build/src/Storages/IStorage.cpp:171: DB::IStorage::truncate(std::shared_ptr const&, std::shared_ptr const&, std::shared_ptr, DB::TableExclusiveLockHolder&) @ 0x0000000015d1ec7a 5. /build/src/Interpreters/InterpreterDropQuery.cpp:282: DB::InterpreterDropQuery::executeToTableImpl(std::shared_ptr const&, DB::ASTDropQuery&, std::shared_ptr&, StrongTypedef, DB::UUIDTag>&) @ 0x0000000014915304 6. /build/src/Interpreters/InterpreterDropQuery.cpp:118: DB::InterpreterDropQuery::executeToTable(DB::ASTDropQuery&) @ 0x00000000149137b4 7. /build/src/Interpreters/InterpreterDropQuery.cpp:91: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000014912f07 8. /build/src/Interpreters/InterpreterDropQuery.cpp:72: DB::InterpreterDropQuery::execute() @ 0x0000000014912b65 9. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88dc9 10. /build/src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x0000000014c8ca7b 11. /build/src/Interpreters/DDLWorker.cpp:510: DB::DDLWorker::tryExecuteQuery(DB::DDLTaskBase&, std::shared_ptr const&, bool) @ 0x00000000144dab9e 12. /build/src/Interpreters/DDLWorker.cpp:675: DB::DDLWorker::processTask(DB::DDLTaskBase&, std::shared_ptr const&, bool) @ 0x00000000144d8ffe 13. /build/src/Databases/DatabaseReplicatedWorker.cpp:372: DB::DatabaseReplicatedDDLWorker::tryEnqueueAndExecuteEntry(DB::DDLLogEntry&, std::shared_ptr, bool) @ 0x0000000013dc29ab 14. /build/src/Databases/DatabaseReplicated.cpp:1139: DB::DatabaseReplicated::tryEnqueueReplicatedDDL(std::shared_ptr const&, std::shared_ptr, DB::QueryFlags) @ 0x0000000013d9f73c 15. /build/src/Interpreters/InterpreterDropQuery.cpp:226: DB::InterpreterDropQuery::executeToTableImpl(std::shared_ptr const&, DB::ASTDropQuery&, std::shared_ptr&, StrongTypedef, DB::UUIDTag>&) @ 0x0000000014914ed7 16. /build/src/Interpreters/InterpreterDropQuery.cpp:118: DB::InterpreterDropQuery::executeToTable(DB::ASTDropQuery&) @ 0x00000000149137b4 17. /build/src/Interpreters/InterpreterDropQuery.cpp:91: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000014912f07 18. /build/src/Interpreters/InterpreterDropQuery.cpp:72: DB::InterpreterDropQuery::execute() @ 0x0000000014912b65 19. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88dc9 20. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 21. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 22. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 23. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 24. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 25. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 26. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 27. ? @ 0x00007fbc6213eac3 28. ? @ 0x00007fbc621d0850 2025.07.28 11:56:45.167037 [ 3287 ] {1120dd29-1858-46bf-88ae-edfd4a2185ff} executeQuery: Code: 48. DB::Exception: Truncate is not supported by storage Null. (NOT_IMPLEMENTED) (version 25.3.6.10636.altinitytest (altinity build)) (from [::1]:56432) (comment: 01072_optimize_skip_unused_shards_const_expr_eval.sql) (query 40, line 50) (in query: -- check virtual columns drop table data_01072;), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x000000000a06b56b 4. /build/src/Storages/IStorage.cpp:171: DB::IStorage::truncate(std::shared_ptr const&, std::shared_ptr const&, std::shared_ptr, DB::TableExclusiveLockHolder&) @ 0x0000000015d1ec7a 5. /build/src/Interpreters/InterpreterDropQuery.cpp:282: DB::InterpreterDropQuery::executeToTableImpl(std::shared_ptr const&, DB::ASTDropQuery&, std::shared_ptr&, StrongTypedef, DB::UUIDTag>&) @ 0x0000000014915304 6. /build/src/Interpreters/InterpreterDropQuery.cpp:118: DB::InterpreterDropQuery::executeToTable(DB::ASTDropQuery&) @ 0x00000000149137b4 7. /build/src/Interpreters/InterpreterDropQuery.cpp:91: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000014912f07 8. /build/src/Interpreters/InterpreterDropQuery.cpp:72: DB::InterpreterDropQuery::execute() @ 0x0000000014912b65 9. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88dc9 10. /build/src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x0000000014c8ca7b 11. /build/src/Interpreters/DDLWorker.cpp:510: DB::DDLWorker::tryExecuteQuery(DB::DDLTaskBase&, std::shared_ptr const&, bool) @ 0x00000000144dab9e 12. /build/src/Interpreters/DDLWorker.cpp:675: DB::DDLWorker::processTask(DB::DDLTaskBase&, std::shared_ptr const&, bool) @ 0x00000000144d8ffe 13. /build/src/Databases/DatabaseReplicatedWorker.cpp:372: DB::DatabaseReplicatedDDLWorker::tryEnqueueAndExecuteEntry(DB::DDLLogEntry&, std::shared_ptr, bool) @ 0x0000000013dc29ab 14. /build/src/Databases/DatabaseReplicated.cpp:1139: DB::DatabaseReplicated::tryEnqueueReplicatedDDL(std::shared_ptr const&, std::shared_ptr, DB::QueryFlags) @ 0x0000000013d9f73c 15. /build/src/Interpreters/InterpreterDropQuery.cpp:226: DB::InterpreterDropQuery::executeToTableImpl(std::shared_ptr const&, DB::ASTDropQuery&, std::shared_ptr&, StrongTypedef, DB::UUIDTag>&) @ 0x0000000014914ed7 16. /build/src/Interpreters/InterpreterDropQuery.cpp:118: DB::InterpreterDropQuery::executeToTable(DB::ASTDropQuery&) @ 0x00000000149137b4 17. /build/src/Interpreters/InterpreterDropQuery.cpp:91: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000014912f07 18. /build/src/Interpreters/InterpreterDropQuery.cpp:72: DB::InterpreterDropQuery::execute() @ 0x0000000014912b65 19. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88dc9 20. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 21. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 22. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 23. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 24. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 25. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 26. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 27. ? @ 0x00007fbc6213eac3 28. ? @ 0x00007fbc621d0850 2025.07.28 11:56:45.189989 [ 3287 ] {} 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. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x000000000a06b56b 4. /build/src/Storages/IStorage.cpp:171: DB::IStorage::truncate(std::shared_ptr const&, std::shared_ptr const&, std::shared_ptr, DB::TableExclusiveLockHolder&) @ 0x0000000015d1ec7a 5. /build/src/Interpreters/InterpreterDropQuery.cpp:282: DB::InterpreterDropQuery::executeToTableImpl(std::shared_ptr const&, DB::ASTDropQuery&, std::shared_ptr&, StrongTypedef, DB::UUIDTag>&) @ 0x0000000014915304 6. /build/src/Interpreters/InterpreterDropQuery.cpp:118: DB::InterpreterDropQuery::executeToTable(DB::ASTDropQuery&) @ 0x00000000149137b4 7. /build/src/Interpreters/InterpreterDropQuery.cpp:91: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000014912f07 8. /build/src/Interpreters/InterpreterDropQuery.cpp:72: DB::InterpreterDropQuery::execute() @ 0x0000000014912b65 9. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88dc9 10. /build/src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x0000000014c8ca7b 11. /build/src/Interpreters/DDLWorker.cpp:510: DB::DDLWorker::tryExecuteQuery(DB::DDLTaskBase&, std::shared_ptr const&, bool) @ 0x00000000144dab9e 12. /build/src/Interpreters/DDLWorker.cpp:675: DB::DDLWorker::processTask(DB::DDLTaskBase&, std::shared_ptr const&, bool) @ 0x00000000144d8ffe 13. /build/src/Databases/DatabaseReplicatedWorker.cpp:372: DB::DatabaseReplicatedDDLWorker::tryEnqueueAndExecuteEntry(DB::DDLLogEntry&, std::shared_ptr, bool) @ 0x0000000013dc29ab 14. /build/src/Databases/DatabaseReplicated.cpp:1139: DB::DatabaseReplicated::tryEnqueueReplicatedDDL(std::shared_ptr const&, std::shared_ptr, DB::QueryFlags) @ 0x0000000013d9f73c 15. /build/src/Interpreters/InterpreterDropQuery.cpp:226: DB::InterpreterDropQuery::executeToTableImpl(std::shared_ptr const&, DB::ASTDropQuery&, std::shared_ptr&, StrongTypedef, DB::UUIDTag>&) @ 0x0000000014914ed7 16. /build/src/Interpreters/InterpreterDropQuery.cpp:118: DB::InterpreterDropQuery::executeToTable(DB::ASTDropQuery&) @ 0x00000000149137b4 17. /build/src/Interpreters/InterpreterDropQuery.cpp:91: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000014912f07 18. /build/src/Interpreters/InterpreterDropQuery.cpp:72: DB::InterpreterDropQuery::execute() @ 0x0000000014912b65 19. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88dc9 20. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 21. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 22. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 23. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 24. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 25. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 26. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 27. ? @ 0x00007fbc6213eac3 28. ? @ 0x00007fbc621d0850 2025.07.28 11:56:45.315282 [ 17611 ] {6ec1431b-2194-4e3d-b970-8594f896976c} executeQuery: Code: 48. DB::Exception: Truncate is not supported by storage Null. (NOT_IMPLEMENTED) (version 25.3.6.10636.altinitytest (altinity build)) (from [::1]:36098) (comment: 01072_optimize_skip_unused_shards_const_expr_eval.sql) (in query: DROP DATABASE IF EXISTS test_2k34u9qu SYNC ), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x000000000a06b56b 4. /build/src/Storages/IStorage.cpp:171: DB::IStorage::truncate(std::shared_ptr const&, std::shared_ptr const&, std::shared_ptr, DB::TableExclusiveLockHolder&) @ 0x0000000015d1ec7a 5. /build/src/Interpreters/InterpreterDropQuery.cpp:282: DB::InterpreterDropQuery::executeToTableImpl(std::shared_ptr const&, DB::ASTDropQuery&, std::shared_ptr&, StrongTypedef, DB::UUIDTag>&) @ 0x0000000014915304 6. /build/src/Interpreters/InterpreterDropQuery.cpp:461: DB::InterpreterDropQuery::executeToDatabaseImpl(DB::ASTDropQuery const&, std::shared_ptr&, std::vector, DB::UUIDTag>, std::allocator, DB::UUIDTag>>>&) @ 0x0000000014917707 7. /build/src/Interpreters/InterpreterDropQuery.cpp:363: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x0000000014913988 8. /build/src/Interpreters/InterpreterDropQuery.cpp:99: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000014913142 9. /build/src/Interpreters/InterpreterDropQuery.cpp:72: DB::InterpreterDropQuery::execute() @ 0x0000000014912b65 10. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88dc9 11. /build/src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x0000000014c8ca7b 12. /build/src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000001686da12 13. /build/src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x0000000016870807 14. /build/src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x0000000016907e99 15. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 16. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 17. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 18. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 19. ? @ 0x00007fbc6213eac3 20. ? @ 0x00007fbc621d0850 2025.07.28 11:56:45.317911 [ 17611 ] {6ec1431b-2194-4e3d-b970-8594f896976c} 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. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x000000000a06b56b 4. /build/src/Storages/IStorage.cpp:171: DB::IStorage::truncate(std::shared_ptr const&, std::shared_ptr const&, std::shared_ptr, DB::TableExclusiveLockHolder&) @ 0x0000000015d1ec7a 5. /build/src/Interpreters/InterpreterDropQuery.cpp:282: DB::InterpreterDropQuery::executeToTableImpl(std::shared_ptr const&, DB::ASTDropQuery&, std::shared_ptr&, StrongTypedef, DB::UUIDTag>&) @ 0x0000000014915304 6. /build/src/Interpreters/InterpreterDropQuery.cpp:461: DB::InterpreterDropQuery::executeToDatabaseImpl(DB::ASTDropQuery const&, std::shared_ptr&, std::vector, DB::UUIDTag>, std::allocator, DB::UUIDTag>>>&) @ 0x0000000014917707 7. /build/src/Interpreters/InterpreterDropQuery.cpp:363: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x0000000014913988 8. /build/src/Interpreters/InterpreterDropQuery.cpp:99: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000014913142 9. /build/src/Interpreters/InterpreterDropQuery.cpp:72: DB::InterpreterDropQuery::execute() @ 0x0000000014912b65 10. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88dc9 11. /build/src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x0000000014c8ca7b 12. /build/src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000001686da12 13. /build/src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x0000000016870807 14. /build/src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x0000000016907e99 15. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 16. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 17. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 18. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 19. ? @ 0x00007fbc6213eac3 20. ? @ 0x00007fbc621d0850 (version 25.3.6.10636.altinitytest (altinity build)) 2025.07.28 11:56:45.368919 [ 17306 ] {f42b0c95-a140-475d-9def-bc322a653772} executeQuery: Code: 253. DB::Exception: Replica r1 of shard s1 of replicated database at /test/db/test_14 already exists. Replica host ID: '146b4357c08d:9000:2e9f5a5a-d01a-404b-9f39-a9efc39ca82f', current host ID: '146b4357c08d:9000:15857af1-1aac-4b19-8b2e-60bb9ad3ff15'. (REPLICA_ALREADY_EXISTS) (version 25.3.6.10636.altinitytest (altinity build)) (from [::1]:36100) (comment: 02243_make_date32.sql) (in query: CREATE DATABASE IF NOT EXISTS test_cxs6v3kd ENGINE=Replicated('/test/db/test_14', 's1', 'r1') ), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.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&) @ 0x0000000013db5399 4. /build/src/Databases/DatabaseReplicated.cpp:494: DB::DatabaseReplicated::tryConnectToZooKeeperAndInitDatabase(DB::LoadingStrictnessLevel) @ 0x0000000013d91155 5. /build/src/Databases/DatabaseReplicated.cpp:735: DB::DatabaseReplicated::beforeLoadingMetadata(std::shared_ptr, DB::LoadingStrictnessLevel) @ 0x0000000013d954d4 6. /build/src/Databases/TablesLoader.cpp:57: DB::TablesLoader::loadTablesAsync(std::unordered_set, std::hash>, std::equal_to>, std::allocator>>) @ 0x000000001490e734 7. /build/src/Interpreters/InterpreterCreateQuery.cpp:383: DB::InterpreterCreateQuery::createDatabase(DB::ASTCreateQuery&) @ 0x00000000148e8e14 8. /build/src/Interpreters/InterpreterCreateQuery.cpp:2351: DB::InterpreterCreateQuery::execute() @ 0x0000000014905a3a 9. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88dc9 10. /build/src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x0000000014c8ca7b 11. /build/src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000001686da12 12. /build/src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x0000000016870807 13. /build/src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x0000000016907e99 14. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 15. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 16. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 17. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 18. ? @ 0x00007fbc6213eac3 19. ? @ 0x00007fbc621d0850 2025.07.28 11:56:45.370799 [ 17306 ] {f42b0c95-a140-475d-9def-bc322a653772} DynamicQueryHandler: Code: 253. DB::Exception: Replica r1 of shard s1 of replicated database at /test/db/test_14 already exists. Replica host ID: '146b4357c08d:9000:2e9f5a5a-d01a-404b-9f39-a9efc39ca82f', current host ID: '146b4357c08d:9000:15857af1-1aac-4b19-8b2e-60bb9ad3ff15'. (REPLICA_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.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&) @ 0x0000000013db5399 4. /build/src/Databases/DatabaseReplicated.cpp:494: DB::DatabaseReplicated::tryConnectToZooKeeperAndInitDatabase(DB::LoadingStrictnessLevel) @ 0x0000000013d91155 5. /build/src/Databases/DatabaseReplicated.cpp:735: DB::DatabaseReplicated::beforeLoadingMetadata(std::shared_ptr, DB::LoadingStrictnessLevel) @ 0x0000000013d954d4 6. /build/src/Databases/TablesLoader.cpp:57: DB::TablesLoader::loadTablesAsync(std::unordered_set, std::hash>, std::equal_to>, std::allocator>>) @ 0x000000001490e734 7. /build/src/Interpreters/InterpreterCreateQuery.cpp:383: DB::InterpreterCreateQuery::createDatabase(DB::ASTCreateQuery&) @ 0x00000000148e8e14 8. /build/src/Interpreters/InterpreterCreateQuery.cpp:2351: DB::InterpreterCreateQuery::execute() @ 0x0000000014905a3a 9. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88dc9 10. /build/src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x0000000014c8ca7b 11. /build/src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000001686da12 12. /build/src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x0000000016870807 13. /build/src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x0000000016907e99 14. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 15. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 16. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 17. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 18. ? @ 0x00007fbc6213eac3 19. ? @ 0x00007fbc621d0850 (version 25.3.6.10636.altinitytest (altinity build)) 2025.07.28 11:56:45.405790 [ 17232 ] {4809fcc0-7e96-48c4-b73b-673ce619d532} executeQuery: Code: 253. DB::Exception: Replica r1 of shard s1 of replicated database at /test/db/test_14 already exists. Replica host ID: '146b4357c08d:9000:2e9f5a5a-d01a-404b-9f39-a9efc39ca82f', current host ID: '146b4357c08d:9000:0a218130-69d5-4b08-9e2a-77a82dbbc511'. (REPLICA_ALREADY_EXISTS) (version 25.3.6.10636.altinitytest (altinity build)) (from [::1]:36106) (comment: 03037_dynamic_merges_2_horizontal_compact_merge_tree.sql) (in query: CREATE DATABASE IF NOT EXISTS test_3vvb7hx7 ENGINE=Replicated('/test/db/test_14', 's1', 'r1') ), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.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&) @ 0x0000000013db5399 4. /build/src/Databases/DatabaseReplicated.cpp:494: DB::DatabaseReplicated::tryConnectToZooKeeperAndInitDatabase(DB::LoadingStrictnessLevel) @ 0x0000000013d91155 5. /build/src/Databases/DatabaseReplicated.cpp:735: DB::DatabaseReplicated::beforeLoadingMetadata(std::shared_ptr, DB::LoadingStrictnessLevel) @ 0x0000000013d954d4 6. /build/src/Databases/TablesLoader.cpp:57: DB::TablesLoader::loadTablesAsync(std::unordered_set, std::hash>, std::equal_to>, std::allocator>>) @ 0x000000001490e734 7. /build/src/Interpreters/InterpreterCreateQuery.cpp:383: DB::InterpreterCreateQuery::createDatabase(DB::ASTCreateQuery&) @ 0x00000000148e8e14 8. /build/src/Interpreters/InterpreterCreateQuery.cpp:2351: DB::InterpreterCreateQuery::execute() @ 0x0000000014905a3a 9. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88dc9 10. /build/src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x0000000014c8ca7b 11. /build/src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000001686da12 12. /build/src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x0000000016870807 13. /build/src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x0000000016907e99 14. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 15. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 16. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 17. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 18. ? @ 0x00007fbc6213eac3 19. ? @ 0x00007fbc621d0850 2025.07.28 11:56:45.407195 [ 17232 ] {4809fcc0-7e96-48c4-b73b-673ce619d532} DynamicQueryHandler: Code: 253. DB::Exception: Replica r1 of shard s1 of replicated database at /test/db/test_14 already exists. Replica host ID: '146b4357c08d:9000:2e9f5a5a-d01a-404b-9f39-a9efc39ca82f', current host ID: '146b4357c08d:9000:0a218130-69d5-4b08-9e2a-77a82dbbc511'. (REPLICA_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.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&) @ 0x0000000013db5399 4. /build/src/Databases/DatabaseReplicated.cpp:494: DB::DatabaseReplicated::tryConnectToZooKeeperAndInitDatabase(DB::LoadingStrictnessLevel) @ 0x0000000013d91155 5. /build/src/Databases/DatabaseReplicated.cpp:735: DB::DatabaseReplicated::beforeLoadingMetadata(std::shared_ptr, DB::LoadingStrictnessLevel) @ 0x0000000013d954d4 6. /build/src/Databases/TablesLoader.cpp:57: DB::TablesLoader::loadTablesAsync(std::unordered_set, std::hash>, std::equal_to>, std::allocator>>) @ 0x000000001490e734 7. /build/src/Interpreters/InterpreterCreateQuery.cpp:383: DB::InterpreterCreateQuery::createDatabase(DB::ASTCreateQuery&) @ 0x00000000148e8e14 8. /build/src/Interpreters/InterpreterCreateQuery.cpp:2351: DB::InterpreterCreateQuery::execute() @ 0x0000000014905a3a 9. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88dc9 10. /build/src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x0000000014c8ca7b 11. /build/src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000001686da12 12. /build/src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x0000000016870807 13. /build/src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x0000000016907e99 14. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 15. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 16. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 17. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 18. ? @ 0x00007fbc6213eac3 19. ? @ 0x00007fbc621d0850 (version 25.3.6.10636.altinitytest (altinity build)) 2025.07.28 11:56:45.490678 [ 17306 ] {c24a533c-26b4-41fa-83d7-f97880096ce0} executeQuery: Code: 253. DB::Exception: Replica r1 of shard s1 of replicated database at /test/db/test_14 already exists. Replica host ID: '146b4357c08d:9000:2e9f5a5a-d01a-404b-9f39-a9efc39ca82f', current host ID: '146b4357c08d:9000:08c15392-f1b2-4188-9196-417fd79f754f'. (REPLICA_ALREADY_EXISTS) (version 25.3.6.10636.altinitytest (altinity build)) (from [::1]:36108) (comment: 02835_join_step_explain.sql) (in query: CREATE DATABASE IF NOT EXISTS test_v96h1s19 ENGINE=Replicated('/test/db/test_14', 's1', 'r1') ), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.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&) @ 0x0000000013db5399 4. /build/src/Databases/DatabaseReplicated.cpp:494: DB::DatabaseReplicated::tryConnectToZooKeeperAndInitDatabase(DB::LoadingStrictnessLevel) @ 0x0000000013d91155 5. /build/src/Databases/DatabaseReplicated.cpp:735: DB::DatabaseReplicated::beforeLoadingMetadata(std::shared_ptr, DB::LoadingStrictnessLevel) @ 0x0000000013d954d4 6. /build/src/Databases/TablesLoader.cpp:57: DB::TablesLoader::loadTablesAsync(std::unordered_set, std::hash>, std::equal_to>, std::allocator>>) @ 0x000000001490e734 7. /build/src/Interpreters/InterpreterCreateQuery.cpp:383: DB::InterpreterCreateQuery::createDatabase(DB::ASTCreateQuery&) @ 0x00000000148e8e14 8. /build/src/Interpreters/InterpreterCreateQuery.cpp:2351: DB::InterpreterCreateQuery::execute() @ 0x0000000014905a3a 9. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88dc9 10. /build/src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x0000000014c8ca7b 11. /build/src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000001686da12 12. /build/src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x0000000016870807 13. /build/src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x0000000016907e99 14. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 15. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 16. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 17. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 18. ? @ 0x00007fbc6213eac3 19. ? @ 0x00007fbc621d0850 2025.07.28 11:56:45.495252 [ 17306 ] {c24a533c-26b4-41fa-83d7-f97880096ce0} DynamicQueryHandler: Code: 253. DB::Exception: Replica r1 of shard s1 of replicated database at /test/db/test_14 already exists. Replica host ID: '146b4357c08d:9000:2e9f5a5a-d01a-404b-9f39-a9efc39ca82f', current host ID: '146b4357c08d:9000:08c15392-f1b2-4188-9196-417fd79f754f'. (REPLICA_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.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&) @ 0x0000000013db5399 4. /build/src/Databases/DatabaseReplicated.cpp:494: DB::DatabaseReplicated::tryConnectToZooKeeperAndInitDatabase(DB::LoadingStrictnessLevel) @ 0x0000000013d91155 5. /build/src/Databases/DatabaseReplicated.cpp:735: DB::DatabaseReplicated::beforeLoadingMetadata(std::shared_ptr, DB::LoadingStrictnessLevel) @ 0x0000000013d954d4 6. /build/src/Databases/TablesLoader.cpp:57: DB::TablesLoader::loadTablesAsync(std::unordered_set, std::hash>, std::equal_to>, std::allocator>>) @ 0x000000001490e734 7. /build/src/Interpreters/InterpreterCreateQuery.cpp:383: DB::InterpreterCreateQuery::createDatabase(DB::ASTCreateQuery&) @ 0x00000000148e8e14 8. /build/src/Interpreters/InterpreterCreateQuery.cpp:2351: DB::InterpreterCreateQuery::execute() @ 0x0000000014905a3a 9. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88dc9 10. /build/src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x0000000014c8ca7b 11. /build/src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000001686da12 12. /build/src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x0000000016870807 13. /build/src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x0000000016907e99 14. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 15. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 16. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 17. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 18. ? @ 0x00007fbc6213eac3 19. ? @ 0x00007fbc621d0850 (version 25.3.6.10636.altinitytest (altinity build)) 2025.07.28 11:56:45.553205 [ 17306 ] {40b0e578-73a4-47ac-8836-c5b441a79076} executeQuery: Code: 253. DB::Exception: Replica r1 of shard s1 of replicated database at /test/db/test_14 already exists. Replica host ID: '146b4357c08d:9000:2e9f5a5a-d01a-404b-9f39-a9efc39ca82f', current host ID: '146b4357c08d:9000:17064d85-ed18-4650-b4dc-55d2b1006330'. (REPLICA_ALREADY_EXISTS) (version 25.3.6.10636.altinitytest (altinity build)) (from [::1]:36114) (comment: 00112_shard_totals_after_having.sql) (in query: CREATE DATABASE IF NOT EXISTS test_9177y4ua ENGINE=Replicated('/test/db/test_14', 's1', 'r1') ), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.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&) @ 0x0000000013db5399 4. /build/src/Databases/DatabaseReplicated.cpp:494: DB::DatabaseReplicated::tryConnectToZooKeeperAndInitDatabase(DB::LoadingStrictnessLevel) @ 0x0000000013d91155 5. /build/src/Databases/DatabaseReplicated.cpp:735: DB::DatabaseReplicated::beforeLoadingMetadata(std::shared_ptr, DB::LoadingStrictnessLevel) @ 0x0000000013d954d4 6. /build/src/Databases/TablesLoader.cpp:57: DB::TablesLoader::loadTablesAsync(std::unordered_set, std::hash>, std::equal_to>, std::allocator>>) @ 0x000000001490e734 7. /build/src/Interpreters/InterpreterCreateQuery.cpp:383: DB::InterpreterCreateQuery::createDatabase(DB::ASTCreateQuery&) @ 0x00000000148e8e14 8. /build/src/Interpreters/InterpreterCreateQuery.cpp:2351: DB::InterpreterCreateQuery::execute() @ 0x0000000014905a3a 9. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88dc9 10. /build/src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x0000000014c8ca7b 11. /build/src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000001686da12 12. /build/src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x0000000016870807 13. /build/src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x0000000016907e99 14. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 15. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 16. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 17. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 18. ? @ 0x00007fbc6213eac3 19. ? @ 0x00007fbc621d0850 2025.07.28 11:56:45.557170 [ 17306 ] {40b0e578-73a4-47ac-8836-c5b441a79076} DynamicQueryHandler: Code: 253. DB::Exception: Replica r1 of shard s1 of replicated database at /test/db/test_14 already exists. Replica host ID: '146b4357c08d:9000:2e9f5a5a-d01a-404b-9f39-a9efc39ca82f', current host ID: '146b4357c08d:9000:17064d85-ed18-4650-b4dc-55d2b1006330'. (REPLICA_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.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&) @ 0x0000000013db5399 4. /build/src/Databases/DatabaseReplicated.cpp:494: DB::DatabaseReplicated::tryConnectToZooKeeperAndInitDatabase(DB::LoadingStrictnessLevel) @ 0x0000000013d91155 5. /build/src/Databases/DatabaseReplicated.cpp:735: DB::DatabaseReplicated::beforeLoadingMetadata(std::shared_ptr, DB::LoadingStrictnessLevel) @ 0x0000000013d954d4 6. /build/src/Databases/TablesLoader.cpp:57: DB::TablesLoader::loadTablesAsync(std::unordered_set, std::hash>, std::equal_to>, std::allocator>>) @ 0x000000001490e734 7. /build/src/Interpreters/InterpreterCreateQuery.cpp:383: DB::InterpreterCreateQuery::createDatabase(DB::ASTCreateQuery&) @ 0x00000000148e8e14 8. /build/src/Interpreters/InterpreterCreateQuery.cpp:2351: DB::InterpreterCreateQuery::execute() @ 0x0000000014905a3a 9. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88dc9 10. /build/src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x0000000014c8ca7b 11. /build/src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000001686da12 12. /build/src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x0000000016870807 13. /build/src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x0000000016907e99 14. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 15. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 16. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 17. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 18. ? @ 0x00007fbc6213eac3 19. ? @ 0x00007fbc621d0850 (version 25.3.6.10636.altinitytest (altinity build)) 2025.07.28 11:56:45.595733 [ 17232 ] {3ec41818-1eee-4e48-93ea-95b9656a6826} executeQuery: Code: 253. DB::Exception: Replica r1 of shard s1 of replicated database at /test/db/test_14 already exists. Replica host ID: '146b4357c08d:9000:2e9f5a5a-d01a-404b-9f39-a9efc39ca82f', current host ID: '146b4357c08d:9000:6d3a84e6-fa4e-440d-82c1-04ccb0d7d076'. (REPLICA_ALREADY_EXISTS) (version 25.3.6.10636.altinitytest (altinity build)) (from [::1]:36120) (comment: 03311_subcolumns_in_default_and_materialized_expressions.sql) (in query: CREATE DATABASE IF NOT EXISTS test_sm7ztqrv ENGINE=Replicated('/test/db/test_14', 's1', 'r1') ), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.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&) @ 0x0000000013db5399 4. /build/src/Databases/DatabaseReplicated.cpp:494: DB::DatabaseReplicated::tryConnectToZooKeeperAndInitDatabase(DB::LoadingStrictnessLevel) @ 0x0000000013d91155 5. /build/src/Databases/DatabaseReplicated.cpp:735: DB::DatabaseReplicated::beforeLoadingMetadata(std::shared_ptr, DB::LoadingStrictnessLevel) @ 0x0000000013d954d4 6. /build/src/Databases/TablesLoader.cpp:57: DB::TablesLoader::loadTablesAsync(std::unordered_set, std::hash>, std::equal_to>, std::allocator>>) @ 0x000000001490e734 7. /build/src/Interpreters/InterpreterCreateQuery.cpp:383: DB::InterpreterCreateQuery::createDatabase(DB::ASTCreateQuery&) @ 0x00000000148e8e14 8. /build/src/Interpreters/InterpreterCreateQuery.cpp:2351: DB::InterpreterCreateQuery::execute() @ 0x0000000014905a3a 9. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88dc9 10. /build/src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x0000000014c8ca7b 11. /build/src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000001686da12 12. /build/src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x0000000016870807 13. /build/src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x0000000016907e99 14. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 15. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 16. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 17. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 18. ? @ 0x00007fbc6213eac3 19. ? @ 0x00007fbc621d0850 2025.07.28 11:56:45.600975 [ 17232 ] {3ec41818-1eee-4e48-93ea-95b9656a6826} DynamicQueryHandler: Code: 253. DB::Exception: Replica r1 of shard s1 of replicated database at /test/db/test_14 already exists. Replica host ID: '146b4357c08d:9000:2e9f5a5a-d01a-404b-9f39-a9efc39ca82f', current host ID: '146b4357c08d:9000:6d3a84e6-fa4e-440d-82c1-04ccb0d7d076'. (REPLICA_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.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&) @ 0x0000000013db5399 4. /build/src/Databases/DatabaseReplicated.cpp:494: DB::DatabaseReplicated::tryConnectToZooKeeperAndInitDatabase(DB::LoadingStrictnessLevel) @ 0x0000000013d91155 5. /build/src/Databases/DatabaseReplicated.cpp:735: DB::DatabaseReplicated::beforeLoadingMetadata(std::shared_ptr, DB::LoadingStrictnessLevel) @ 0x0000000013d954d4 6. /build/src/Databases/TablesLoader.cpp:57: DB::TablesLoader::loadTablesAsync(std::unordered_set, std::hash>, std::equal_to>, std::allocator>>) @ 0x000000001490e734 7. /build/src/Interpreters/InterpreterCreateQuery.cpp:383: DB::InterpreterCreateQuery::createDatabase(DB::ASTCreateQuery&) @ 0x00000000148e8e14 8. /build/src/Interpreters/InterpreterCreateQuery.cpp:2351: DB::InterpreterCreateQuery::execute() @ 0x0000000014905a3a 9. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88dc9 10. /build/src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x0000000014c8ca7b 11. /build/src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000001686da12 12. /build/src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x0000000016870807 13. /build/src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x0000000016907e99 14. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 15. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 16. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 17. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 18. ? @ 0x00007fbc6213eac3 19. ? @ 0x00007fbc621d0850 (version 25.3.6.10636.altinitytest (altinity build)) 2025.07.28 11:56:45.662261 [ 17306 ] {a7725940-5178-4bc3-a1b3-95e458a6db02} executeQuery: Code: 253. DB::Exception: Replica r1 of shard s1 of replicated database at /test/db/test_14 already exists. Replica host ID: '146b4357c08d:9000:2e9f5a5a-d01a-404b-9f39-a9efc39ca82f', current host ID: '146b4357c08d:9000:a2b84ce4-04e7-4072-8d0a-b6184f65f8ac'. (REPLICA_ALREADY_EXISTS) (version 25.3.6.10636.altinitytest (altinity build)) (from [::1]:36132) (comment: 01518_nullable_aggregate_states1.sql) (in query: CREATE DATABASE IF NOT EXISTS test_3tqbb23o ENGINE=Replicated('/test/db/test_14', 's1', 'r1') ), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.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&) @ 0x0000000013db5399 4. /build/src/Databases/DatabaseReplicated.cpp:494: DB::DatabaseReplicated::tryConnectToZooKeeperAndInitDatabase(DB::LoadingStrictnessLevel) @ 0x0000000013d91155 5. /build/src/Databases/DatabaseReplicated.cpp:735: DB::DatabaseReplicated::beforeLoadingMetadata(std::shared_ptr, DB::LoadingStrictnessLevel) @ 0x0000000013d954d4 6. /build/src/Databases/TablesLoader.cpp:57: DB::TablesLoader::loadTablesAsync(std::unordered_set, std::hash>, std::equal_to>, std::allocator>>) @ 0x000000001490e734 7. /build/src/Interpreters/InterpreterCreateQuery.cpp:383: DB::InterpreterCreateQuery::createDatabase(DB::ASTCreateQuery&) @ 0x00000000148e8e14 8. /build/src/Interpreters/InterpreterCreateQuery.cpp:2351: DB::InterpreterCreateQuery::execute() @ 0x0000000014905a3a 9. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88dc9 10. /build/src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x0000000014c8ca7b 11. /build/src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000001686da12 12. /build/src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x0000000016870807 13. /build/src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x0000000016907e99 14. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 15. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 16. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 17. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 18. ? @ 0x00007fbc6213eac3 19. ? @ 0x00007fbc621d0850 2025.07.28 11:56:45.664758 [ 17306 ] {a7725940-5178-4bc3-a1b3-95e458a6db02} DynamicQueryHandler: Code: 253. DB::Exception: Replica r1 of shard s1 of replicated database at /test/db/test_14 already exists. Replica host ID: '146b4357c08d:9000:2e9f5a5a-d01a-404b-9f39-a9efc39ca82f', current host ID: '146b4357c08d:9000:a2b84ce4-04e7-4072-8d0a-b6184f65f8ac'. (REPLICA_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.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&) @ 0x0000000013db5399 4. /build/src/Databases/DatabaseReplicated.cpp:494: DB::DatabaseReplicated::tryConnectToZooKeeperAndInitDatabase(DB::LoadingStrictnessLevel) @ 0x0000000013d91155 5. /build/src/Databases/DatabaseReplicated.cpp:735: DB::DatabaseReplicated::beforeLoadingMetadata(std::shared_ptr, DB::LoadingStrictnessLevel) @ 0x0000000013d954d4 6. /build/src/Databases/TablesLoader.cpp:57: DB::TablesLoader::loadTablesAsync(std::unordered_set, std::hash>, std::equal_to>, std::allocator>>) @ 0x000000001490e734 7. /build/src/Interpreters/InterpreterCreateQuery.cpp:383: DB::InterpreterCreateQuery::createDatabase(DB::ASTCreateQuery&) @ 0x00000000148e8e14 8. /build/src/Interpreters/InterpreterCreateQuery.cpp:2351: DB::InterpreterCreateQuery::execute() @ 0x0000000014905a3a 9. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88dc9 10. /build/src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x0000000014c8ca7b 11. /build/src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000001686da12 12. /build/src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x0000000016870807 13. /build/src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x0000000016907e99 14. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 15. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 16. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 17. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 18. ? @ 0x00007fbc6213eac3 19. ? @ 0x00007fbc621d0850 (version 25.3.6.10636.altinitytest (altinity build)) 2025.07.28 11:56:45.783984 [ 17232 ] {20a13a71-5dd3-4f91-86ac-ac6776a5443f} executeQuery: Code: 253. DB::Exception: Replica r1 of shard s1 of replicated database at /test/db/test_14 already exists. Replica host ID: '146b4357c08d:9000:2e9f5a5a-d01a-404b-9f39-a9efc39ca82f', current host ID: '146b4357c08d:9000:314a3556-048a-45c2-ad67-047450bb869b'. (REPLICA_ALREADY_EXISTS) (version 25.3.6.10636.altinitytest (altinity build)) (from [::1]:36148) (comment: 01752_distributed_query_sigsegv.sql) (in query: CREATE DATABASE IF NOT EXISTS test_xtso81u1 ENGINE=Replicated('/test/db/test_14', 's1', 'r1') ), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.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&) @ 0x0000000013db5399 4. /build/src/Databases/DatabaseReplicated.cpp:494: DB::DatabaseReplicated::tryConnectToZooKeeperAndInitDatabase(DB::LoadingStrictnessLevel) @ 0x0000000013d91155 5. /build/src/Databases/DatabaseReplicated.cpp:735: DB::DatabaseReplicated::beforeLoadingMetadata(std::shared_ptr, DB::LoadingStrictnessLevel) @ 0x0000000013d954d4 6. /build/src/Databases/TablesLoader.cpp:57: DB::TablesLoader::loadTablesAsync(std::unordered_set, std::hash>, std::equal_to>, std::allocator>>) @ 0x000000001490e734 7. /build/src/Interpreters/InterpreterCreateQuery.cpp:383: DB::InterpreterCreateQuery::createDatabase(DB::ASTCreateQuery&) @ 0x00000000148e8e14 8. /build/src/Interpreters/InterpreterCreateQuery.cpp:2351: DB::InterpreterCreateQuery::execute() @ 0x0000000014905a3a 9. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88dc9 10. /build/src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x0000000014c8ca7b 11. /build/src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000001686da12 12. /build/src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x0000000016870807 13. /build/src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x0000000016907e99 14. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 15. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 16. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 17. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 18. ? @ 0x00007fbc6213eac3 19. ? @ 0x00007fbc621d0850 2025.07.28 11:56:45.787856 [ 17232 ] {20a13a71-5dd3-4f91-86ac-ac6776a5443f} DynamicQueryHandler: Code: 253. DB::Exception: Replica r1 of shard s1 of replicated database at /test/db/test_14 already exists. Replica host ID: '146b4357c08d:9000:2e9f5a5a-d01a-404b-9f39-a9efc39ca82f', current host ID: '146b4357c08d:9000:314a3556-048a-45c2-ad67-047450bb869b'. (REPLICA_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.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&) @ 0x0000000013db5399 4. /build/src/Databases/DatabaseReplicated.cpp:494: DB::DatabaseReplicated::tryConnectToZooKeeperAndInitDatabase(DB::LoadingStrictnessLevel) @ 0x0000000013d91155 5. /build/src/Databases/DatabaseReplicated.cpp:735: DB::DatabaseReplicated::beforeLoadingMetadata(std::shared_ptr, DB::LoadingStrictnessLevel) @ 0x0000000013d954d4 6. /build/src/Databases/TablesLoader.cpp:57: DB::TablesLoader::loadTablesAsync(std::unordered_set, std::hash>, std::equal_to>, std::allocator>>) @ 0x000000001490e734 7. /build/src/Interpreters/InterpreterCreateQuery.cpp:383: DB::InterpreterCreateQuery::createDatabase(DB::ASTCreateQuery&) @ 0x00000000148e8e14 8. /build/src/Interpreters/InterpreterCreateQuery.cpp:2351: DB::InterpreterCreateQuery::execute() @ 0x0000000014905a3a 9. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88dc9 10. /build/src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x0000000014c8ca7b 11. /build/src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000001686da12 12. /build/src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x0000000016870807 13. /build/src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x0000000016907e99 14. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 15. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 16. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 17. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 18. ? @ 0x00007fbc6213eac3 19. ? @ 0x00007fbc621d0850 (version 25.3.6.10636.altinitytest (altinity build)) 2025.07.28 11:56:45.825633 [ 17306 ] {82d3c122-1434-4d7a-983d-93cfdf19f21a} executeQuery: Code: 253. DB::Exception: Replica r1 of shard s1 of replicated database at /test/db/test_14 already exists. Replica host ID: '146b4357c08d:9000:2e9f5a5a-d01a-404b-9f39-a9efc39ca82f', current host ID: '146b4357c08d:9000:5cabf81b-b221-4178-9baf-81da8c511c08'. (REPLICA_ALREADY_EXISTS) (version 25.3.6.10636.altinitytest (altinity build)) (from [::1]:36152) (comment: 02935_http_content_type_with_http_headers_progress.sh) (in query: CREATE DATABASE IF NOT EXISTS test_zi3100gy ENGINE=Replicated('/test/db/test_14', 's1', 'r1') ), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.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&) @ 0x0000000013db5399 4. /build/src/Databases/DatabaseReplicated.cpp:494: DB::DatabaseReplicated::tryConnectToZooKeeperAndInitDatabase(DB::LoadingStrictnessLevel) @ 0x0000000013d91155 5. /build/src/Databases/DatabaseReplicated.cpp:735: DB::DatabaseReplicated::beforeLoadingMetadata(std::shared_ptr, DB::LoadingStrictnessLevel) @ 0x0000000013d954d4 6. /build/src/Databases/TablesLoader.cpp:57: DB::TablesLoader::loadTablesAsync(std::unordered_set, std::hash>, std::equal_to>, std::allocator>>) @ 0x000000001490e734 7. /build/src/Interpreters/InterpreterCreateQuery.cpp:383: DB::InterpreterCreateQuery::createDatabase(DB::ASTCreateQuery&) @ 0x00000000148e8e14 8. /build/src/Interpreters/InterpreterCreateQuery.cpp:2351: DB::InterpreterCreateQuery::execute() @ 0x0000000014905a3a 9. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88dc9 10. /build/src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x0000000014c8ca7b 11. /build/src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000001686da12 12. /build/src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x0000000016870807 13. /build/src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x0000000016907e99 14. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 15. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 16. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 17. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 18. ? @ 0x00007fbc6213eac3 19. ? @ 0x00007fbc621d0850 2025.07.28 11:56:45.834051 [ 17306 ] {82d3c122-1434-4d7a-983d-93cfdf19f21a} DynamicQueryHandler: Code: 253. DB::Exception: Replica r1 of shard s1 of replicated database at /test/db/test_14 already exists. Replica host ID: '146b4357c08d:9000:2e9f5a5a-d01a-404b-9f39-a9efc39ca82f', current host ID: '146b4357c08d:9000:5cabf81b-b221-4178-9baf-81da8c511c08'. (REPLICA_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.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&) @ 0x0000000013db5399 4. /build/src/Databases/DatabaseReplicated.cpp:494: DB::DatabaseReplicated::tryConnectToZooKeeperAndInitDatabase(DB::LoadingStrictnessLevel) @ 0x0000000013d91155 5. /build/src/Databases/DatabaseReplicated.cpp:735: DB::DatabaseReplicated::beforeLoadingMetadata(std::shared_ptr, DB::LoadingStrictnessLevel) @ 0x0000000013d954d4 6. /build/src/Databases/TablesLoader.cpp:57: DB::TablesLoader::loadTablesAsync(std::unordered_set, std::hash>, std::equal_to>, std::allocator>>) @ 0x000000001490e734 7. /build/src/Interpreters/InterpreterCreateQuery.cpp:383: DB::InterpreterCreateQuery::createDatabase(DB::ASTCreateQuery&) @ 0x00000000148e8e14 8. /build/src/Interpreters/InterpreterCreateQuery.cpp:2351: DB::InterpreterCreateQuery::execute() @ 0x0000000014905a3a 9. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88dc9 10. /build/src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x0000000014c8ca7b 11. /build/src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000001686da12 12. /build/src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x0000000016870807 13. /build/src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x0000000016907e99 14. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 15. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 16. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 17. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 18. ? @ 0x00007fbc6213eac3 19. ? @ 0x00007fbc621d0850 (version 25.3.6.10636.altinitytest (altinity build)) 2025.07.28 11:56:45.880837 [ 17232 ] {72cea574-6699-4f72-8d01-d22127a2728e} executeQuery: Code: 253. DB::Exception: Replica r1 of shard s1 of replicated database at /test/db/test_14 already exists. Replica host ID: '146b4357c08d:9000:2e9f5a5a-d01a-404b-9f39-a9efc39ca82f', current host ID: '146b4357c08d:9000:3627260e-cfee-4592-a725-a568021f01b9'. (REPLICA_ALREADY_EXISTS) (version 25.3.6.10636.altinitytest (altinity build)) (from [::1]:36168) (comment: 02001_compress_output_file.sh) (in query: CREATE DATABASE IF NOT EXISTS test_upteoh0b ENGINE=Replicated('/test/db/test_14', 's1', 'r1') ), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.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&) @ 0x0000000013db5399 4. /build/src/Databases/DatabaseReplicated.cpp:494: DB::DatabaseReplicated::tryConnectToZooKeeperAndInitDatabase(DB::LoadingStrictnessLevel) @ 0x0000000013d91155 5. /build/src/Databases/DatabaseReplicated.cpp:735: DB::DatabaseReplicated::beforeLoadingMetadata(std::shared_ptr, DB::LoadingStrictnessLevel) @ 0x0000000013d954d4 6. /build/src/Databases/TablesLoader.cpp:57: DB::TablesLoader::loadTablesAsync(std::unordered_set, std::hash>, std::equal_to>, std::allocator>>) @ 0x000000001490e734 7. /build/src/Interpreters/InterpreterCreateQuery.cpp:383: DB::InterpreterCreateQuery::createDatabase(DB::ASTCreateQuery&) @ 0x00000000148e8e14 8. /build/src/Interpreters/InterpreterCreateQuery.cpp:2351: DB::InterpreterCreateQuery::execute() @ 0x0000000014905a3a 9. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88dc9 10. /build/src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x0000000014c8ca7b 11. /build/src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000001686da12 12. /build/src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x0000000016870807 13. /build/src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x0000000016907e99 14. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 15. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 16. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 17. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 18. ? @ 0x00007fbc6213eac3 19. ? @ 0x00007fbc621d0850 2025.07.28 11:56:45.891940 [ 17232 ] {72cea574-6699-4f72-8d01-d22127a2728e} DynamicQueryHandler: Code: 253. DB::Exception: Replica r1 of shard s1 of replicated database at /test/db/test_14 already exists. Replica host ID: '146b4357c08d:9000:2e9f5a5a-d01a-404b-9f39-a9efc39ca82f', current host ID: '146b4357c08d:9000:3627260e-cfee-4592-a725-a568021f01b9'. (REPLICA_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.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&) @ 0x0000000013db5399 4. /build/src/Databases/DatabaseReplicated.cpp:494: DB::DatabaseReplicated::tryConnectToZooKeeperAndInitDatabase(DB::LoadingStrictnessLevel) @ 0x0000000013d91155 5. /build/src/Databases/DatabaseReplicated.cpp:735: DB::DatabaseReplicated::beforeLoadingMetadata(std::shared_ptr, DB::LoadingStrictnessLevel) @ 0x0000000013d954d4 6. /build/src/Databases/TablesLoader.cpp:57: DB::TablesLoader::loadTablesAsync(std::unordered_set, std::hash>, std::equal_to>, std::allocator>>) @ 0x000000001490e734 7. /build/src/Interpreters/InterpreterCreateQuery.cpp:383: DB::InterpreterCreateQuery::createDatabase(DB::ASTCreateQuery&) @ 0x00000000148e8e14 8. /build/src/Interpreters/InterpreterCreateQuery.cpp:2351: DB::InterpreterCreateQuery::execute() @ 0x0000000014905a3a 9. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88dc9 10. /build/src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x0000000014c8ca7b 11. /build/src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000001686da12 12. /build/src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x0000000016870807 13. /build/src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x0000000016907e99 14. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 15. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 16. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 17. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 18. ? @ 0x00007fbc6213eac3 19. ? @ 0x00007fbc621d0850 (version 25.3.6.10636.altinitytest (altinity build)) 2025.07.28 11:56:46.030618 [ 17306 ] {cd424452-025e-420e-9438-905ca2d98507} executeQuery: Code: 253. DB::Exception: Replica r1 of shard s1 of replicated database at /test/db/test_14 already exists. Replica host ID: '146b4357c08d:9000:2e9f5a5a-d01a-404b-9f39-a9efc39ca82f', current host ID: '146b4357c08d:9000:1ede9a15-4408-4e2d-bbe9-1d2a3fcc4e7b'. (REPLICA_ALREADY_EXISTS) (version 25.3.6.10636.altinitytest (altinity build)) (from [::1]:36176) (comment: 02785_summing_merge_tree_datetime64.sql) (in query: CREATE DATABASE IF NOT EXISTS test_ptzauhoh ENGINE=Replicated('/test/db/test_14', 's1', 'r1') ), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.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&) @ 0x0000000013db5399 4. /build/src/Databases/DatabaseReplicated.cpp:494: DB::DatabaseReplicated::tryConnectToZooKeeperAndInitDatabase(DB::LoadingStrictnessLevel) @ 0x0000000013d91155 5. /build/src/Databases/DatabaseReplicated.cpp:735: DB::DatabaseReplicated::beforeLoadingMetadata(std::shared_ptr, DB::LoadingStrictnessLevel) @ 0x0000000013d954d4 6. /build/src/Databases/TablesLoader.cpp:57: DB::TablesLoader::loadTablesAsync(std::unordered_set, std::hash>, std::equal_to>, std::allocator>>) @ 0x000000001490e734 7. /build/src/Interpreters/InterpreterCreateQuery.cpp:383: DB::InterpreterCreateQuery::createDatabase(DB::ASTCreateQuery&) @ 0x00000000148e8e14 8. /build/src/Interpreters/InterpreterCreateQuery.cpp:2351: DB::InterpreterCreateQuery::execute() @ 0x0000000014905a3a 9. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88dc9 10. /build/src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x0000000014c8ca7b 11. /build/src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000001686da12 12. /build/src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x0000000016870807 13. /build/src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x0000000016907e99 14. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 15. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 16. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 17. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 18. ? @ 0x00007fbc6213eac3 19. ? @ 0x00007fbc621d0850 2025.07.28 11:56:46.033751 [ 17306 ] {cd424452-025e-420e-9438-905ca2d98507} DynamicQueryHandler: Code: 253. DB::Exception: Replica r1 of shard s1 of replicated database at /test/db/test_14 already exists. Replica host ID: '146b4357c08d:9000:2e9f5a5a-d01a-404b-9f39-a9efc39ca82f', current host ID: '146b4357c08d:9000:1ede9a15-4408-4e2d-bbe9-1d2a3fcc4e7b'. (REPLICA_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.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&) @ 0x0000000013db5399 4. /build/src/Databases/DatabaseReplicated.cpp:494: DB::DatabaseReplicated::tryConnectToZooKeeperAndInitDatabase(DB::LoadingStrictnessLevel) @ 0x0000000013d91155 5. /build/src/Databases/DatabaseReplicated.cpp:735: DB::DatabaseReplicated::beforeLoadingMetadata(std::shared_ptr, DB::LoadingStrictnessLevel) @ 0x0000000013d954d4 6. /build/src/Databases/TablesLoader.cpp:57: DB::TablesLoader::loadTablesAsync(std::unordered_set, std::hash>, std::equal_to>, std::allocator>>) @ 0x000000001490e734 7. /build/src/Interpreters/InterpreterCreateQuery.cpp:383: DB::InterpreterCreateQuery::createDatabase(DB::ASTCreateQuery&) @ 0x00000000148e8e14 8. /build/src/Interpreters/InterpreterCreateQuery.cpp:2351: DB::InterpreterCreateQuery::execute() @ 0x0000000014905a3a 9. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88dc9 10. /build/src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x0000000014c8ca7b 11. /build/src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000001686da12 12. /build/src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x0000000016870807 13. /build/src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x0000000016907e99 14. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 15. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 16. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 17. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 18. ? @ 0x00007fbc6213eac3 19. ? @ 0x00007fbc621d0850 (version 25.3.6.10636.altinitytest (altinity build)) 2025.07.28 11:56:46.122740 [ 3974 ] {} test_13.rmt2 (7f9b740d-015c-470e-8cc6-8ba33be0dc63): auto DB::StorageReplicatedMergeTree::processQueueEntry(ReplicatedMergeTreeQueue::SelectedEntryPtr)::(anonymous class)::operator()(LogEntryPtr &) const: Code: 86. DB::HTTPException: Received error from remote server http://146b4357c08d:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Ftest%2F01165%2Ftest_13%2Frmt%2Freplicas%2F1&part=20250728_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.6.10636.altinitytest (altinity build)) '. (RECEIVED_ERROR_FROM_REMOTE_IO_SERVER), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.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 const&, int&&, String const&, unsigned long&&, String const&) @ 0x000000000feda8d9 4. /build/src/IO/HTTPCommon.cpp:104: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x000000000feda6e2 5. /build/src/IO/HTTPCommon.cpp:93: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x000000000feda537 6. /build/src/IO/ReadWriteBufferFromHTTP.cpp:277: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x000000001184a4c4 7. /build/src/IO/ReadWriteBufferFromHTTP.cpp:285: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x000000001184a615 8. /build/src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x000000001184ae59 9. /build/src/IO/ReadWriteBufferFromHTTP.cpp:472: void std::__function::__policy_invoker::__call_impl[abi:se190107]>(std::__function::__policy_storage const*) @ 0x000000001184cedd 10. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001184858b 11. /build/src/IO/ReadWriteBufferFromHTTP.cpp:465: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x000000001184bf0b 12. /build/src/IO/ReadBuffer.h:60: DB::ReadBuffer::next() @ 0x000000000a148c7b 13. /build/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) @ 0x0000000011849fb2 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]>&)>&, 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&) @ 0x0000000011841980 15. /build/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) @ 0x000000001621208e 16. /build/src/Storages/StorageReplicatedMergeTree.cpp:5228: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl[abi:se190107] const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000015f9a5fe 17. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000015ed8bfd 18. /build/src/Storages/StorageReplicatedMergeTree.cpp:2514: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x0000000015ec9aab 19. /build/src/Storages/StorageReplicatedMergeTree.cpp:2349: DB::StorageReplicatedMergeTree::executeLogEntry(DB::ReplicatedMergeTreeLogEntry&) @ 0x0000000015eba91b 20. /build/src/Storages/StorageReplicatedMergeTree.cpp:3876: bool std::__function::__policy_invoker&)>::__call_impl[abi:se190107])::$_1, bool (std::shared_ptr&)>>(std::__function::__policy_storage const*, std::shared_ptr&) @ 0x0000000015f9837e 21. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000165d6fc3 22. /build/src/Storages/StorageReplicatedMergeTree.cpp:3872: DB::StorageReplicatedMergeTree::processQueueEntry(std::shared_ptr) @ 0x0000000015efc18a 23. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001624c1b2 24. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000162f9c70 25. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x00000000162fa55a 26. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc6653 27. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000000fccc4c3 28. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc3d92 29. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fcca080 30. ? @ 0x00007fbc6213eac3 31. ? @ 0x00007fbc621d0850 (version 25.3.6.10636.altinitytest (altinity build)) 2025.07.28 11:56:46.151374 [ 17306 ] {43e5bcb4-c90c-406f-b588-b4924502c845} executeQuery: Code: 253. DB::Exception: Replica r1 of shard s1 of replicated database at /test/db/test_14 already exists. Replica host ID: '146b4357c08d:9000:2e9f5a5a-d01a-404b-9f39-a9efc39ca82f', current host ID: '146b4357c08d:9000:80dcd134-93ef-4e1a-9de9-072d99769f51'. (REPLICA_ALREADY_EXISTS) (version 25.3.6.10636.altinitytest (altinity build)) (from [::1]:36188) (comment: 01942_dateTimeToSnowflakeID.sql) (in query: CREATE DATABASE IF NOT EXISTS test_554hf8wc ENGINE=Replicated('/test/db/test_14', 's1', 'r1') ), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.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&) @ 0x0000000013db5399 4. /build/src/Databases/DatabaseReplicated.cpp:494: DB::DatabaseReplicated::tryConnectToZooKeeperAndInitDatabase(DB::LoadingStrictnessLevel) @ 0x0000000013d91155 5. /build/src/Databases/DatabaseReplicated.cpp:735: DB::DatabaseReplicated::beforeLoadingMetadata(std::shared_ptr, DB::LoadingStrictnessLevel) @ 0x0000000013d954d4 6. /build/src/Databases/TablesLoader.cpp:57: DB::TablesLoader::loadTablesAsync(std::unordered_set, std::hash>, std::equal_to>, std::allocator>>) @ 0x000000001490e734 7. /build/src/Interpreters/InterpreterCreateQuery.cpp:383: DB::InterpreterCreateQuery::createDatabase(DB::ASTCreateQuery&) @ 0x00000000148e8e14 8. /build/src/Interpreters/InterpreterCreateQuery.cpp:2351: DB::InterpreterCreateQuery::execute() @ 0x0000000014905a3a 9. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88dc9 10. /build/src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x0000000014c8ca7b 11. /build/src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000001686da12 12. /build/src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x0000000016870807 13. /build/src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x0000000016907e99 14. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 15. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 16. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 17. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 18. ? @ 0x00007fbc6213eac3 19. ? @ 0x00007fbc621d0850 2025.07.28 11:56:46.152616 [ 17306 ] {43e5bcb4-c90c-406f-b588-b4924502c845} DynamicQueryHandler: Code: 253. DB::Exception: Replica r1 of shard s1 of replicated database at /test/db/test_14 already exists. Replica host ID: '146b4357c08d:9000:2e9f5a5a-d01a-404b-9f39-a9efc39ca82f', current host ID: '146b4357c08d:9000:80dcd134-93ef-4e1a-9de9-072d99769f51'. (REPLICA_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.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&) @ 0x0000000013db5399 4. /build/src/Databases/DatabaseReplicated.cpp:494: DB::DatabaseReplicated::tryConnectToZooKeeperAndInitDatabase(DB::LoadingStrictnessLevel) @ 0x0000000013d91155 5. /build/src/Databases/DatabaseReplicated.cpp:735: DB::DatabaseReplicated::beforeLoadingMetadata(std::shared_ptr, DB::LoadingStrictnessLevel) @ 0x0000000013d954d4 6. /build/src/Databases/TablesLoader.cpp:57: DB::TablesLoader::loadTablesAsync(std::unordered_set, std::hash>, std::equal_to>, std::allocator>>) @ 0x000000001490e734 7. /build/src/Interpreters/InterpreterCreateQuery.cpp:383: DB::InterpreterCreateQuery::createDatabase(DB::ASTCreateQuery&) @ 0x00000000148e8e14 8. /build/src/Interpreters/InterpreterCreateQuery.cpp:2351: DB::InterpreterCreateQuery::execute() @ 0x0000000014905a3a 9. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88dc9 10. /build/src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x0000000014c8ca7b 11. /build/src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000001686da12 12. /build/src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x0000000016870807 13. /build/src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x0000000016907e99 14. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 15. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 16. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 17. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 18. ? @ 0x00007fbc6213eac3 19. ? @ 0x00007fbc621d0850 (version 25.3.6.10636.altinitytest (altinity build)) 2025.07.28 11:56:46.196241 [ 17232 ] {00136923-afea-41f7-92e9-7371cdcfb455} executeQuery: Code: 253. DB::Exception: Replica r1 of shard s1 of replicated database at /test/db/test_14 already exists. Replica host ID: '146b4357c08d:9000:2e9f5a5a-d01a-404b-9f39-a9efc39ca82f', current host ID: '146b4357c08d:9000:054d2ae4-b989-4960-8f5c-11857b5c6c63'. (REPLICA_ALREADY_EXISTS) (version 25.3.6.10636.altinitytest (altinity build)) (from [::1]:36194) (comment: 00612_http_max_query_size_for_distributed.sql) (in query: CREATE DATABASE IF NOT EXISTS test_i7xnf8tm ENGINE=Replicated('/test/db/test_14', 's1', 'r1') ), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.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&) @ 0x0000000013db5399 4. /build/src/Databases/DatabaseReplicated.cpp:494: DB::DatabaseReplicated::tryConnectToZooKeeperAndInitDatabase(DB::LoadingStrictnessLevel) @ 0x0000000013d91155 5. /build/src/Databases/DatabaseReplicated.cpp:735: DB::DatabaseReplicated::beforeLoadingMetadata(std::shared_ptr, DB::LoadingStrictnessLevel) @ 0x0000000013d954d4 6. /build/src/Databases/TablesLoader.cpp:57: DB::TablesLoader::loadTablesAsync(std::unordered_set, std::hash>, std::equal_to>, std::allocator>>) @ 0x000000001490e734 7. /build/src/Interpreters/InterpreterCreateQuery.cpp:383: DB::InterpreterCreateQuery::createDatabase(DB::ASTCreateQuery&) @ 0x00000000148e8e14 8. /build/src/Interpreters/InterpreterCreateQuery.cpp:2351: DB::InterpreterCreateQuery::execute() @ 0x0000000014905a3a 9. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88dc9 10. /build/src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x0000000014c8ca7b 11. /build/src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000001686da12 12. /build/src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x0000000016870807 13. /build/src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x0000000016907e99 14. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 15. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 16. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 17. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 18. ? @ 0x00007fbc6213eac3 19. ? @ 0x00007fbc621d0850 2025.07.28 11:56:46.198278 [ 17232 ] {00136923-afea-41f7-92e9-7371cdcfb455} DynamicQueryHandler: Code: 253. DB::Exception: Replica r1 of shard s1 of replicated database at /test/db/test_14 already exists. Replica host ID: '146b4357c08d:9000:2e9f5a5a-d01a-404b-9f39-a9efc39ca82f', current host ID: '146b4357c08d:9000:054d2ae4-b989-4960-8f5c-11857b5c6c63'. (REPLICA_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.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&) @ 0x0000000013db5399 4. /build/src/Databases/DatabaseReplicated.cpp:494: DB::DatabaseReplicated::tryConnectToZooKeeperAndInitDatabase(DB::LoadingStrictnessLevel) @ 0x0000000013d91155 5. /build/src/Databases/DatabaseReplicated.cpp:735: DB::DatabaseReplicated::beforeLoadingMetadata(std::shared_ptr, DB::LoadingStrictnessLevel) @ 0x0000000013d954d4 6. /build/src/Databases/TablesLoader.cpp:57: DB::TablesLoader::loadTablesAsync(std::unordered_set, std::hash>, std::equal_to>, std::allocator>>) @ 0x000000001490e734 7. /build/src/Interpreters/InterpreterCreateQuery.cpp:383: DB::InterpreterCreateQuery::createDatabase(DB::ASTCreateQuery&) @ 0x00000000148e8e14 8. /build/src/Interpreters/InterpreterCreateQuery.cpp:2351: DB::InterpreterCreateQuery::execute() @ 0x0000000014905a3a 9. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88dc9 10. /build/src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x0000000014c8ca7b 11. /build/src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000001686da12 12. /build/src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x0000000016870807 13. /build/src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x0000000016907e99 14. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 15. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 16. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 17. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 18. ? @ 0x00007fbc6213eac3 19. ? @ 0x00007fbc621d0850 (version 25.3.6.10636.altinitytest (altinity build)) 2025.07.28 11:56:46.238463 [ 17611 ] {19244e7e-740d-4b31-9a56-36d60bff0852} executeQuery: Code: 253. DB::Exception: Replica r1 of shard s1 of replicated database at /test/db/test_14 already exists. Replica host ID: '146b4357c08d:9000:2e9f5a5a-d01a-404b-9f39-a9efc39ca82f', current host ID: '146b4357c08d:9000:0c308394-ced0-4dc4-a1c9-e8b93f3d48fd'. (REPLICA_ALREADY_EXISTS) (version 25.3.6.10636.altinitytest (altinity build)) (from [::1]:36198) (comment: 01940_pad_string.sql) (in query: CREATE DATABASE IF NOT EXISTS test_zv870dr8 ENGINE=Replicated('/test/db/test_14', 's1', 'r1') ), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.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&) @ 0x0000000013db5399 4. /build/src/Databases/DatabaseReplicated.cpp:494: DB::DatabaseReplicated::tryConnectToZooKeeperAndInitDatabase(DB::LoadingStrictnessLevel) @ 0x0000000013d91155 5. /build/src/Databases/DatabaseReplicated.cpp:735: DB::DatabaseReplicated::beforeLoadingMetadata(std::shared_ptr, DB::LoadingStrictnessLevel) @ 0x0000000013d954d4 6. /build/src/Databases/TablesLoader.cpp:57: DB::TablesLoader::loadTablesAsync(std::unordered_set, std::hash>, std::equal_to>, std::allocator>>) @ 0x000000001490e734 7. /build/src/Interpreters/InterpreterCreateQuery.cpp:383: DB::InterpreterCreateQuery::createDatabase(DB::ASTCreateQuery&) @ 0x00000000148e8e14 8. /build/src/Interpreters/InterpreterCreateQuery.cpp:2351: DB::InterpreterCreateQuery::execute() @ 0x0000000014905a3a 9. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88dc9 10. /build/src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x0000000014c8ca7b 11. /build/src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000001686da12 12. /build/src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x0000000016870807 13. /build/src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x0000000016907e99 14. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 15. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 16. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 17. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 18. ? @ 0x00007fbc6213eac3 19. ? @ 0x00007fbc621d0850 2025.07.28 11:56:46.240566 [ 17611 ] {19244e7e-740d-4b31-9a56-36d60bff0852} DynamicQueryHandler: Code: 253. DB::Exception: Replica r1 of shard s1 of replicated database at /test/db/test_14 already exists. Replica host ID: '146b4357c08d:9000:2e9f5a5a-d01a-404b-9f39-a9efc39ca82f', current host ID: '146b4357c08d:9000:0c308394-ced0-4dc4-a1c9-e8b93f3d48fd'. (REPLICA_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.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&) @ 0x0000000013db5399 4. /build/src/Databases/DatabaseReplicated.cpp:494: DB::DatabaseReplicated::tryConnectToZooKeeperAndInitDatabase(DB::LoadingStrictnessLevel) @ 0x0000000013d91155 5. /build/src/Databases/DatabaseReplicated.cpp:735: DB::DatabaseReplicated::beforeLoadingMetadata(std::shared_ptr, DB::LoadingStrictnessLevel) @ 0x0000000013d954d4 6. /build/src/Databases/TablesLoader.cpp:57: DB::TablesLoader::loadTablesAsync(std::unordered_set, std::hash>, std::equal_to>, std::allocator>>) @ 0x000000001490e734 7. /build/src/Interpreters/InterpreterCreateQuery.cpp:383: DB::InterpreterCreateQuery::createDatabase(DB::ASTCreateQuery&) @ 0x00000000148e8e14 8. /build/src/Interpreters/InterpreterCreateQuery.cpp:2351: DB::InterpreterCreateQuery::execute() @ 0x0000000014905a3a 9. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88dc9 10. /build/src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x0000000014c8ca7b 11. /build/src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000001686da12 12. /build/src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x0000000016870807 13. /build/src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x0000000016907e99 14. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 15. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 16. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 17. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 18. ? @ 0x00007fbc6213eac3 19. ? @ 0x00007fbc621d0850 (version 25.3.6.10636.altinitytest (altinity build)) 2025.07.28 11:56:46.296016 [ 17232 ] {c7d931de-0eb7-46b9-bc59-ac35dbbf2ee6} executeQuery: Code: 253. DB::Exception: Replica r1 of shard s1 of replicated database at /test/db/test_14 already exists. Replica host ID: '146b4357c08d:9000:2e9f5a5a-d01a-404b-9f39-a9efc39ca82f', current host ID: '146b4357c08d:9000:61717c39-3045-47e0-9b07-3eac38e75ba5'. (REPLICA_ALREADY_EXISTS) (version 25.3.6.10636.altinitytest (altinity build)) (from [::1]:36200) (comment: 00846_join_using_tuple_crash.sql) (in query: CREATE DATABASE IF NOT EXISTS test_6ijnckl3 ENGINE=Replicated('/test/db/test_14', 's1', 'r1') ), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.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&) @ 0x0000000013db5399 4. /build/src/Databases/DatabaseReplicated.cpp:494: DB::DatabaseReplicated::tryConnectToZooKeeperAndInitDatabase(DB::LoadingStrictnessLevel) @ 0x0000000013d91155 5. /build/src/Databases/DatabaseReplicated.cpp:735: DB::DatabaseReplicated::beforeLoadingMetadata(std::shared_ptr, DB::LoadingStrictnessLevel) @ 0x0000000013d954d4 6. /build/src/Databases/TablesLoader.cpp:57: DB::TablesLoader::loadTablesAsync(std::unordered_set, std::hash>, std::equal_to>, std::allocator>>) @ 0x000000001490e734 7. /build/src/Interpreters/InterpreterCreateQuery.cpp:383: DB::InterpreterCreateQuery::createDatabase(DB::ASTCreateQuery&) @ 0x00000000148e8e14 8. /build/src/Interpreters/InterpreterCreateQuery.cpp:2351: DB::InterpreterCreateQuery::execute() @ 0x0000000014905a3a 9. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88dc9 10. /build/src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x0000000014c8ca7b 11. /build/src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000001686da12 12. /build/src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x0000000016870807 13. /build/src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x0000000016907e99 14. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 15. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 16. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 17. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 18. ? @ 0x00007fbc6213eac3 19. ? @ 0x00007fbc621d0850 2025.07.28 11:56:46.297904 [ 17232 ] {c7d931de-0eb7-46b9-bc59-ac35dbbf2ee6} DynamicQueryHandler: Code: 253. DB::Exception: Replica r1 of shard s1 of replicated database at /test/db/test_14 already exists. Replica host ID: '146b4357c08d:9000:2e9f5a5a-d01a-404b-9f39-a9efc39ca82f', current host ID: '146b4357c08d:9000:61717c39-3045-47e0-9b07-3eac38e75ba5'. (REPLICA_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.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&) @ 0x0000000013db5399 4. /build/src/Databases/DatabaseReplicated.cpp:494: DB::DatabaseReplicated::tryConnectToZooKeeperAndInitDatabase(DB::LoadingStrictnessLevel) @ 0x0000000013d91155 5. /build/src/Databases/DatabaseReplicated.cpp:735: DB::DatabaseReplicated::beforeLoadingMetadata(std::shared_ptr, DB::LoadingStrictnessLevel) @ 0x0000000013d954d4 6. /build/src/Databases/TablesLoader.cpp:57: DB::TablesLoader::loadTablesAsync(std::unordered_set, std::hash>, std::equal_to>, std::allocator>>) @ 0x000000001490e734 7. /build/src/Interpreters/InterpreterCreateQuery.cpp:383: DB::InterpreterCreateQuery::createDatabase(DB::ASTCreateQuery&) @ 0x00000000148e8e14 8. /build/src/Interpreters/InterpreterCreateQuery.cpp:2351: DB::InterpreterCreateQuery::execute() @ 0x0000000014905a3a 9. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88dc9 10. /build/src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x0000000014c8ca7b 11. /build/src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000001686da12 12. /build/src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x0000000016870807 13. /build/src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x0000000016907e99 14. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 15. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 16. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 17. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 18. ? @ 0x00007fbc6213eac3 19. ? @ 0x00007fbc621d0850 (version 25.3.6.10636.altinitytest (altinity build)) 2025.07.28 11:56:46.373096 [ 17611 ] {f11b5a47-81e5-497b-a02b-71eb03c39e19} executeQuery: Code: 253. DB::Exception: Replica r1 of shard s1 of replicated database at /test/db/test_14 already exists. Replica host ID: '146b4357c08d:9000:2e9f5a5a-d01a-404b-9f39-a9efc39ca82f', current host ID: '146b4357c08d:9000:61ed8d5f-d20d-4a31-9314-825dee0a9b1f'. (REPLICA_ALREADY_EXISTS) (version 25.3.6.10636.altinitytest (altinity build)) (from [::1]:36202) (comment: 01854_s2_cap_union.sql) (in query: CREATE DATABASE IF NOT EXISTS test_05yliaz1 ENGINE=Replicated('/test/db/test_14', 's1', 'r1') ), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.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&) @ 0x0000000013db5399 4. /build/src/Databases/DatabaseReplicated.cpp:494: DB::DatabaseReplicated::tryConnectToZooKeeperAndInitDatabase(DB::LoadingStrictnessLevel) @ 0x0000000013d91155 5. /build/src/Databases/DatabaseReplicated.cpp:735: DB::DatabaseReplicated::beforeLoadingMetadata(std::shared_ptr, DB::LoadingStrictnessLevel) @ 0x0000000013d954d4 6. /build/src/Databases/TablesLoader.cpp:57: DB::TablesLoader::loadTablesAsync(std::unordered_set, std::hash>, std::equal_to>, std::allocator>>) @ 0x000000001490e734 7. /build/src/Interpreters/InterpreterCreateQuery.cpp:383: DB::InterpreterCreateQuery::createDatabase(DB::ASTCreateQuery&) @ 0x00000000148e8e14 8. /build/src/Interpreters/InterpreterCreateQuery.cpp:2351: DB::InterpreterCreateQuery::execute() @ 0x0000000014905a3a 9. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88dc9 10. /build/src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x0000000014c8ca7b 11. /build/src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000001686da12 12. /build/src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x0000000016870807 13. /build/src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x0000000016907e99 14. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 15. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 16. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 17. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 18. ? @ 0x00007fbc6213eac3 19. ? @ 0x00007fbc621d0850 2025.07.28 11:56:46.377007 [ 17611 ] {f11b5a47-81e5-497b-a02b-71eb03c39e19} DynamicQueryHandler: Code: 253. DB::Exception: Replica r1 of shard s1 of replicated database at /test/db/test_14 already exists. Replica host ID: '146b4357c08d:9000:2e9f5a5a-d01a-404b-9f39-a9efc39ca82f', current host ID: '146b4357c08d:9000:61ed8d5f-d20d-4a31-9314-825dee0a9b1f'. (REPLICA_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.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&) @ 0x0000000013db5399 4. /build/src/Databases/DatabaseReplicated.cpp:494: DB::DatabaseReplicated::tryConnectToZooKeeperAndInitDatabase(DB::LoadingStrictnessLevel) @ 0x0000000013d91155 5. /build/src/Databases/DatabaseReplicated.cpp:735: DB::DatabaseReplicated::beforeLoadingMetadata(std::shared_ptr, DB::LoadingStrictnessLevel) @ 0x0000000013d954d4 6. /build/src/Databases/TablesLoader.cpp:57: DB::TablesLoader::loadTablesAsync(std::unordered_set, std::hash>, std::equal_to>, std::allocator>>) @ 0x000000001490e734 7. /build/src/Interpreters/InterpreterCreateQuery.cpp:383: DB::InterpreterCreateQuery::createDatabase(DB::ASTCreateQuery&) @ 0x00000000148e8e14 8. /build/src/Interpreters/InterpreterCreateQuery.cpp:2351: DB::InterpreterCreateQuery::execute() @ 0x0000000014905a3a 9. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88dc9 10. /build/src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x0000000014c8ca7b 11. /build/src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000001686da12 12. /build/src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x0000000016870807 13. /build/src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x0000000016907e99 14. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 15. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 16. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 17. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 18. ? @ 0x00007fbc6213eac3 19. ? @ 0x00007fbc621d0850 (version 25.3.6.10636.altinitytest (altinity build)) 2025.07.28 11:56:46.390881 [ 3971 ] {} test_13.rmt2 (7f9b740d-015c-470e-8cc6-8ba33be0dc63): auto DB::StorageReplicatedMergeTree::processQueueEntry(ReplicatedMergeTreeQueue::SelectedEntryPtr)::(anonymous class)::operator()(LogEntryPtr &) const: Code: 86. DB::HTTPException: Received error from remote server http://146b4357c08d:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Ftest%2F01165%2Ftest_13%2Frmt%2Freplicas%2F1&part=20250728_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.6.10636.altinitytest (altinity build)) '. (RECEIVED_ERROR_FROM_REMOTE_IO_SERVER), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.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 const&, int&&, String const&, unsigned long&&, String const&) @ 0x000000000feda8d9 4. /build/src/IO/HTTPCommon.cpp:104: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x000000000feda6e2 5. /build/src/IO/HTTPCommon.cpp:93: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x000000000feda537 6. /build/src/IO/ReadWriteBufferFromHTTP.cpp:277: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x000000001184a4c4 7. /build/src/IO/ReadWriteBufferFromHTTP.cpp:285: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x000000001184a615 8. /build/src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x000000001184ae59 9. /build/src/IO/ReadWriteBufferFromHTTP.cpp:472: void std::__function::__policy_invoker::__call_impl[abi:se190107]>(std::__function::__policy_storage const*) @ 0x000000001184cedd 10. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001184858b 11. /build/src/IO/ReadWriteBufferFromHTTP.cpp:465: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x000000001184bf0b 12. /build/src/IO/ReadBuffer.h:60: DB::ReadBuffer::next() @ 0x000000000a148c7b 13. /build/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) @ 0x0000000011849fb2 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]>&)>&, 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&) @ 0x0000000011841980 15. /build/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) @ 0x000000001621208e 16. /build/src/Storages/StorageReplicatedMergeTree.cpp:5228: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl[abi:se190107] const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000015f9a5fe 17. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000015ed8bfd 18. /build/src/Storages/StorageReplicatedMergeTree.cpp:2514: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x0000000015ec9aab 19. /build/src/Storages/StorageReplicatedMergeTree.cpp:2349: DB::StorageReplicatedMergeTree::executeLogEntry(DB::ReplicatedMergeTreeLogEntry&) @ 0x0000000015eba91b 20. /build/src/Storages/StorageReplicatedMergeTree.cpp:3876: bool std::__function::__policy_invoker&)>::__call_impl[abi:se190107])::$_1, bool (std::shared_ptr&)>>(std::__function::__policy_storage const*, std::shared_ptr&) @ 0x0000000015f9837e 21. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000165d6fc3 22. /build/src/Storages/StorageReplicatedMergeTree.cpp:3872: DB::StorageReplicatedMergeTree::processQueueEntry(std::shared_ptr) @ 0x0000000015efc18a 23. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001624c1b2 24. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000162f9c70 25. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x00000000162fa55a 26. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc6653 27. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000000fccc4c3 28. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc3d92 29. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fcca080 30. ? @ 0x00007fbc6213eac3 31. ? @ 0x00007fbc621d0850 (version 25.3.6.10636.altinitytest (altinity build)) 2025.07.28 11:56:46.422912 [ 17371 ] {ce66ab8c-fac7-4e12-8311-095286d77ba6} executeQuery: Code: 253. DB::Exception: Replica r1 of shard s1 of replicated database at /test/db/test_14 already exists. Replica host ID: '146b4357c08d:9000:2e9f5a5a-d01a-404b-9f39-a9efc39ca82f', current host ID: '146b4357c08d:9000:e9c73758-492f-46d9-835f-5ffb5b98eb2b'. (REPLICA_ALREADY_EXISTS) (version 25.3.6.10636.altinitytest (altinity build)) (from [::1]:36228) (comment: 03002_map_array_functions_with_low_cardinality.sql) (in query: CREATE DATABASE IF NOT EXISTS test_y2azwlg1 ENGINE=Replicated('/test/db/test_14', 's1', 'r1') ), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.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&) @ 0x0000000013db5399 4. /build/src/Databases/DatabaseReplicated.cpp:494: DB::DatabaseReplicated::tryConnectToZooKeeperAndInitDatabase(DB::LoadingStrictnessLevel) @ 0x0000000013d91155 5. /build/src/Databases/DatabaseReplicated.cpp:735: DB::DatabaseReplicated::beforeLoadingMetadata(std::shared_ptr, DB::LoadingStrictnessLevel) @ 0x0000000013d954d4 6. /build/src/Databases/TablesLoader.cpp:57: DB::TablesLoader::loadTablesAsync(std::unordered_set, std::hash>, std::equal_to>, std::allocator>>) @ 0x000000001490e734 7. /build/src/Interpreters/InterpreterCreateQuery.cpp:383: DB::InterpreterCreateQuery::createDatabase(DB::ASTCreateQuery&) @ 0x00000000148e8e14 8. /build/src/Interpreters/InterpreterCreateQuery.cpp:2351: DB::InterpreterCreateQuery::execute() @ 0x0000000014905a3a 9. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88dc9 10. /build/src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x0000000014c8ca7b 11. /build/src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000001686da12 12. /build/src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x0000000016870807 13. /build/src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x0000000016907e99 14. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 15. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 16. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 17. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 18. ? @ 0x00007fbc6213eac3 19. ? @ 0x00007fbc621d0850 2025.07.28 11:56:46.425295 [ 17371 ] {ce66ab8c-fac7-4e12-8311-095286d77ba6} DynamicQueryHandler: Code: 253. DB::Exception: Replica r1 of shard s1 of replicated database at /test/db/test_14 already exists. Replica host ID: '146b4357c08d:9000:2e9f5a5a-d01a-404b-9f39-a9efc39ca82f', current host ID: '146b4357c08d:9000:e9c73758-492f-46d9-835f-5ffb5b98eb2b'. (REPLICA_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.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&) @ 0x0000000013db5399 4. /build/src/Databases/DatabaseReplicated.cpp:494: DB::DatabaseReplicated::tryConnectToZooKeeperAndInitDatabase(DB::LoadingStrictnessLevel) @ 0x0000000013d91155 5. /build/src/Databases/DatabaseReplicated.cpp:735: DB::DatabaseReplicated::beforeLoadingMetadata(std::shared_ptr, DB::LoadingStrictnessLevel) @ 0x0000000013d954d4 6. /build/src/Databases/TablesLoader.cpp:57: DB::TablesLoader::loadTablesAsync(std::unordered_set, std::hash>, std::equal_to>, std::allocator>>) @ 0x000000001490e734 7. /build/src/Interpreters/InterpreterCreateQuery.cpp:383: DB::InterpreterCreateQuery::createDatabase(DB::ASTCreateQuery&) @ 0x00000000148e8e14 8. /build/src/Interpreters/InterpreterCreateQuery.cpp:2351: DB::InterpreterCreateQuery::execute() @ 0x0000000014905a3a 9. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88dc9 10. /build/src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x0000000014c8ca7b 11. /build/src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000001686da12 12. /build/src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x0000000016870807 13. /build/src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x0000000016907e99 14. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 15. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 16. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 17. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 18. ? @ 0x00007fbc6213eac3 19. ? @ 0x00007fbc621d0850 (version 25.3.6.10636.altinitytest (altinity build)) 2025.07.28 11:56:46.531958 [ 17611 ] {ad788b47-6366-457d-a4f8-cf85afd07417} executeQuery: Code: 253. DB::Exception: Replica r1 of shard s1 of replicated database at /test/db/test_14 already exists. Replica host ID: '146b4357c08d:9000:2e9f5a5a-d01a-404b-9f39-a9efc39ca82f', current host ID: '146b4357c08d:9000:d88bfd06-3a6b-451b-93bd-e09f761ec36d'. (REPLICA_ALREADY_EXISTS) (version 25.3.6.10636.altinitytest (altinity build)) (from [::1]:36234) (comment: 03165_storage_merge_view_prewhere.sql) (in query: CREATE DATABASE IF NOT EXISTS test_lkwpc5bn ENGINE=Replicated('/test/db/test_14', 's1', 'r1') ), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.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&) @ 0x0000000013db5399 4. /build/src/Databases/DatabaseReplicated.cpp:494: DB::DatabaseReplicated::tryConnectToZooKeeperAndInitDatabase(DB::LoadingStrictnessLevel) @ 0x0000000013d91155 5. /build/src/Databases/DatabaseReplicated.cpp:735: DB::DatabaseReplicated::beforeLoadingMetadata(std::shared_ptr, DB::LoadingStrictnessLevel) @ 0x0000000013d954d4 6. /build/src/Databases/TablesLoader.cpp:57: DB::TablesLoader::loadTablesAsync(std::unordered_set, std::hash>, std::equal_to>, std::allocator>>) @ 0x000000001490e734 7. /build/src/Interpreters/InterpreterCreateQuery.cpp:383: DB::InterpreterCreateQuery::createDatabase(DB::ASTCreateQuery&) @ 0x00000000148e8e14 8. /build/src/Interpreters/InterpreterCreateQuery.cpp:2351: DB::InterpreterCreateQuery::execute() @ 0x0000000014905a3a 9. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88dc9 10. /build/src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x0000000014c8ca7b 11. /build/src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000001686da12 12. /build/src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x0000000016870807 13. /build/src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x0000000016907e99 14. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 15. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 16. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 17. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 18. ? @ 0x00007fbc6213eac3 19. ? @ 0x00007fbc621d0850 2025.07.28 11:56:46.534034 [ 17611 ] {ad788b47-6366-457d-a4f8-cf85afd07417} DynamicQueryHandler: Code: 253. DB::Exception: Replica r1 of shard s1 of replicated database at /test/db/test_14 already exists. Replica host ID: '146b4357c08d:9000:2e9f5a5a-d01a-404b-9f39-a9efc39ca82f', current host ID: '146b4357c08d:9000:d88bfd06-3a6b-451b-93bd-e09f761ec36d'. (REPLICA_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.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&) @ 0x0000000013db5399 4. /build/src/Databases/DatabaseReplicated.cpp:494: DB::DatabaseReplicated::tryConnectToZooKeeperAndInitDatabase(DB::LoadingStrictnessLevel) @ 0x0000000013d91155 5. /build/src/Databases/DatabaseReplicated.cpp:735: DB::DatabaseReplicated::beforeLoadingMetadata(std::shared_ptr, DB::LoadingStrictnessLevel) @ 0x0000000013d954d4 6. /build/src/Databases/TablesLoader.cpp:57: DB::TablesLoader::loadTablesAsync(std::unordered_set, std::hash>, std::equal_to>, std::allocator>>) @ 0x000000001490e734 7. /build/src/Interpreters/InterpreterCreateQuery.cpp:383: DB::InterpreterCreateQuery::createDatabase(DB::ASTCreateQuery&) @ 0x00000000148e8e14 8. /build/src/Interpreters/InterpreterCreateQuery.cpp:2351: DB::InterpreterCreateQuery::execute() @ 0x0000000014905a3a 9. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88dc9 10. /build/src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x0000000014c8ca7b 11. /build/src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000001686da12 12. /build/src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x0000000016870807 13. /build/src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x0000000016907e99 14. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 15. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 16. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 17. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 18. ? @ 0x00007fbc6213eac3 19. ? @ 0x00007fbc621d0850 (version 25.3.6.10636.altinitytest (altinity build)) 2025.07.28 11:56:46.571213 [ 17232 ] {a4aa9ed3-3cfa-4788-967f-26f8f365a06e} executeQuery: Code: 253. DB::Exception: Replica r1 of shard s1 of replicated database at /test/db/test_14 already exists. Replica host ID: '146b4357c08d:9000:2e9f5a5a-d01a-404b-9f39-a9efc39ca82f', current host ID: '146b4357c08d:9000:7645e987-4fc6-4516-846a-5cdda58c1efc'. (REPLICA_ALREADY_EXISTS) (version 25.3.6.10636.altinitytest (altinity build)) (from [::1]:36248) (comment: 02916_replication_protocol_wait_for_part.sql) (in query: CREATE DATABASE IF NOT EXISTS test_osr8ge74 ENGINE=Replicated('/test/db/test_14', 's1', 'r1') ), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.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&) @ 0x0000000013db5399 4. /build/src/Databases/DatabaseReplicated.cpp:494: DB::DatabaseReplicated::tryConnectToZooKeeperAndInitDatabase(DB::LoadingStrictnessLevel) @ 0x0000000013d91155 5. /build/src/Databases/DatabaseReplicated.cpp:735: DB::DatabaseReplicated::beforeLoadingMetadata(std::shared_ptr, DB::LoadingStrictnessLevel) @ 0x0000000013d954d4 6. /build/src/Databases/TablesLoader.cpp:57: DB::TablesLoader::loadTablesAsync(std::unordered_set, std::hash>, std::equal_to>, std::allocator>>) @ 0x000000001490e734 7. /build/src/Interpreters/InterpreterCreateQuery.cpp:383: DB::InterpreterCreateQuery::createDatabase(DB::ASTCreateQuery&) @ 0x00000000148e8e14 8. /build/src/Interpreters/InterpreterCreateQuery.cpp:2351: DB::InterpreterCreateQuery::execute() @ 0x0000000014905a3a 9. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88dc9 10. /build/src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x0000000014c8ca7b 11. /build/src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000001686da12 12. /build/src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x0000000016870807 13. /build/src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x0000000016907e99 14. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 15. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 16. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 17. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 18. ? @ 0x00007fbc6213eac3 19. ? @ 0x00007fbc621d0850 2025.07.28 11:56:46.572752 [ 17232 ] {a4aa9ed3-3cfa-4788-967f-26f8f365a06e} DynamicQueryHandler: Code: 253. DB::Exception: Replica r1 of shard s1 of replicated database at /test/db/test_14 already exists. Replica host ID: '146b4357c08d:9000:2e9f5a5a-d01a-404b-9f39-a9efc39ca82f', current host ID: '146b4357c08d:9000:7645e987-4fc6-4516-846a-5cdda58c1efc'. (REPLICA_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.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&) @ 0x0000000013db5399 4. /build/src/Databases/DatabaseReplicated.cpp:494: DB::DatabaseReplicated::tryConnectToZooKeeperAndInitDatabase(DB::LoadingStrictnessLevel) @ 0x0000000013d91155 5. /build/src/Databases/DatabaseReplicated.cpp:735: DB::DatabaseReplicated::beforeLoadingMetadata(std::shared_ptr, DB::LoadingStrictnessLevel) @ 0x0000000013d954d4 6. /build/src/Databases/TablesLoader.cpp:57: DB::TablesLoader::loadTablesAsync(std::unordered_set, std::hash>, std::equal_to>, std::allocator>>) @ 0x000000001490e734 7. /build/src/Interpreters/InterpreterCreateQuery.cpp:383: DB::InterpreterCreateQuery::createDatabase(DB::ASTCreateQuery&) @ 0x00000000148e8e14 8. /build/src/Interpreters/InterpreterCreateQuery.cpp:2351: DB::InterpreterCreateQuery::execute() @ 0x0000000014905a3a 9. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88dc9 10. /build/src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x0000000014c8ca7b 11. /build/src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000001686da12 12. /build/src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x0000000016870807 13. /build/src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x0000000016907e99 14. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 15. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 16. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 17. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 18. ? @ 0x00007fbc6213eac3 19. ? @ 0x00007fbc621d0850 (version 25.3.6.10636.altinitytest (altinity build)) 2025.07.28 11:56:46.695858 [ 17306 ] {98dec24f-2ecc-42f8-9145-290cae4f3210} executeQuery: Code: 253. DB::Exception: Replica r1 of shard s1 of replicated database at /test/db/test_14 already exists. Replica host ID: '146b4357c08d:9000:2e9f5a5a-d01a-404b-9f39-a9efc39ca82f', current host ID: '146b4357c08d:9000:44a9c27b-b588-471a-aaa6-60eb552814b1'. (REPLICA_ALREADY_EXISTS) (version 25.3.6.10636.altinitytest (altinity build)) (from [::1]:36262) (comment: 01910_view_dictionary.sql) (in query: CREATE DATABASE IF NOT EXISTS test_3mprcee7 ENGINE=Replicated('/test/db/test_14', 's1', 'r1') ), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.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&) @ 0x0000000013db5399 4. /build/src/Databases/DatabaseReplicated.cpp:494: DB::DatabaseReplicated::tryConnectToZooKeeperAndInitDatabase(DB::LoadingStrictnessLevel) @ 0x0000000013d91155 5. /build/src/Databases/DatabaseReplicated.cpp:735: DB::DatabaseReplicated::beforeLoadingMetadata(std::shared_ptr, DB::LoadingStrictnessLevel) @ 0x0000000013d954d4 6. /build/src/Databases/TablesLoader.cpp:57: DB::TablesLoader::loadTablesAsync(std::unordered_set, std::hash>, std::equal_to>, std::allocator>>) @ 0x000000001490e734 7. /build/src/Interpreters/InterpreterCreateQuery.cpp:383: DB::InterpreterCreateQuery::createDatabase(DB::ASTCreateQuery&) @ 0x00000000148e8e14 8. /build/src/Interpreters/InterpreterCreateQuery.cpp:2351: DB::InterpreterCreateQuery::execute() @ 0x0000000014905a3a 9. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88dc9 10. /build/src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x0000000014c8ca7b 11. /build/src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000001686da12 12. /build/src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x0000000016870807 13. /build/src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x0000000016907e99 14. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 15. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 16. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 17. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 18. ? @ 0x00007fbc6213eac3 19. ? @ 0x00007fbc621d0850 2025.07.28 11:56:46.702551 [ 17306 ] {98dec24f-2ecc-42f8-9145-290cae4f3210} DynamicQueryHandler: Code: 253. DB::Exception: Replica r1 of shard s1 of replicated database at /test/db/test_14 already exists. Replica host ID: '146b4357c08d:9000:2e9f5a5a-d01a-404b-9f39-a9efc39ca82f', current host ID: '146b4357c08d:9000:44a9c27b-b588-471a-aaa6-60eb552814b1'. (REPLICA_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.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&) @ 0x0000000013db5399 4. /build/src/Databases/DatabaseReplicated.cpp:494: DB::DatabaseReplicated::tryConnectToZooKeeperAndInitDatabase(DB::LoadingStrictnessLevel) @ 0x0000000013d91155 5. /build/src/Databases/DatabaseReplicated.cpp:735: DB::DatabaseReplicated::beforeLoadingMetadata(std::shared_ptr, DB::LoadingStrictnessLevel) @ 0x0000000013d954d4 6. /build/src/Databases/TablesLoader.cpp:57: DB::TablesLoader::loadTablesAsync(std::unordered_set, std::hash>, std::equal_to>, std::allocator>>) @ 0x000000001490e734 7. /build/src/Interpreters/InterpreterCreateQuery.cpp:383: DB::InterpreterCreateQuery::createDatabase(DB::ASTCreateQuery&) @ 0x00000000148e8e14 8. /build/src/Interpreters/InterpreterCreateQuery.cpp:2351: DB::InterpreterCreateQuery::execute() @ 0x0000000014905a3a 9. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88dc9 10. /build/src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x0000000014c8ca7b 11. /build/src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000001686da12 12. /build/src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x0000000016870807 13. /build/src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x0000000016907e99 14. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 15. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 16. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 17. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 18. ? @ 0x00007fbc6213eac3 19. ? @ 0x00007fbc621d0850 (version 25.3.6.10636.altinitytest (altinity build)) 2025.07.28 11:56:46.811473 [ 17306 ] {e5f91515-12a6-4b64-a09f-9e0adf38b922} executeQuery: Code: 253. DB::Exception: Replica r1 of shard s1 of replicated database at /test/db/test_14 already exists. Replica host ID: '146b4357c08d:9000:2e9f5a5a-d01a-404b-9f39-a9efc39ca82f', current host ID: '146b4357c08d:9000:913cb540-0527-4895-a9d6-f77e9d44095a'. (REPLICA_ALREADY_EXISTS) (version 25.3.6.10636.altinitytest (altinity build)) (from [::1]:36266) (comment: 02513_insert_without_materialized_columns.sh) (in query: CREATE DATABASE IF NOT EXISTS test_eit37eij ENGINE=Replicated('/test/db/test_14', 's1', 'r1') ), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.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&) @ 0x0000000013db5399 4. /build/src/Databases/DatabaseReplicated.cpp:494: DB::DatabaseReplicated::tryConnectToZooKeeperAndInitDatabase(DB::LoadingStrictnessLevel) @ 0x0000000013d91155 5. /build/src/Databases/DatabaseReplicated.cpp:735: DB::DatabaseReplicated::beforeLoadingMetadata(std::shared_ptr, DB::LoadingStrictnessLevel) @ 0x0000000013d954d4 6. /build/src/Databases/TablesLoader.cpp:57: DB::TablesLoader::loadTablesAsync(std::unordered_set, std::hash>, std::equal_to>, std::allocator>>) @ 0x000000001490e734 7. /build/src/Interpreters/InterpreterCreateQuery.cpp:383: DB::InterpreterCreateQuery::createDatabase(DB::ASTCreateQuery&) @ 0x00000000148e8e14 8. /build/src/Interpreters/InterpreterCreateQuery.cpp:2351: DB::InterpreterCreateQuery::execute() @ 0x0000000014905a3a 9. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88dc9 10. /build/src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x0000000014c8ca7b 11. /build/src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000001686da12 12. /build/src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x0000000016870807 13. /build/src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x0000000016907e99 14. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 15. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 16. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 17. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 18. ? @ 0x00007fbc6213eac3 19. ? @ 0x00007fbc621d0850 2025.07.28 11:56:46.814676 [ 17306 ] {e5f91515-12a6-4b64-a09f-9e0adf38b922} DynamicQueryHandler: Code: 253. DB::Exception: Replica r1 of shard s1 of replicated database at /test/db/test_14 already exists. Replica host ID: '146b4357c08d:9000:2e9f5a5a-d01a-404b-9f39-a9efc39ca82f', current host ID: '146b4357c08d:9000:913cb540-0527-4895-a9d6-f77e9d44095a'. (REPLICA_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.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&) @ 0x0000000013db5399 4. /build/src/Databases/DatabaseReplicated.cpp:494: DB::DatabaseReplicated::tryConnectToZooKeeperAndInitDatabase(DB::LoadingStrictnessLevel) @ 0x0000000013d91155 5. /build/src/Databases/DatabaseReplicated.cpp:735: DB::DatabaseReplicated::beforeLoadingMetadata(std::shared_ptr, DB::LoadingStrictnessLevel) @ 0x0000000013d954d4 6. /build/src/Databases/TablesLoader.cpp:57: DB::TablesLoader::loadTablesAsync(std::unordered_set, std::hash>, std::equal_to>, std::allocator>>) @ 0x000000001490e734 7. /build/src/Interpreters/InterpreterCreateQuery.cpp:383: DB::InterpreterCreateQuery::createDatabase(DB::ASTCreateQuery&) @ 0x00000000148e8e14 8. /build/src/Interpreters/InterpreterCreateQuery.cpp:2351: DB::InterpreterCreateQuery::execute() @ 0x0000000014905a3a 9. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88dc9 10. /build/src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x0000000014c8ca7b 11. /build/src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000001686da12 12. /build/src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x0000000016870807 13. /build/src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x0000000016907e99 14. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 15. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 16. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 17. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 18. ? @ 0x00007fbc6213eac3 19. ? @ 0x00007fbc621d0850 (version 25.3.6.10636.altinitytest (altinity build)) 2025.07.28 11:56:46.882031 [ 17611 ] {ba5198c8-c958-4d6e-9919-a7237fe5d171} executeQuery: Code: 253. DB::Exception: Replica r1 of shard s1 of replicated database at /test/db/test_14 already exists. Replica host ID: '146b4357c08d:9000:2e9f5a5a-d01a-404b-9f39-a9efc39ca82f', current host ID: '146b4357c08d:9000:184ddfef-7c6d-4259-8e08-b0a8b9ec4eff'. (REPLICA_ALREADY_EXISTS) (version 25.3.6.10636.altinitytest (altinity build)) (from [::1]:36270) (comment: 02240_filesystem_cache_bypass_cache_threshold.sql) (in query: CREATE DATABASE IF NOT EXISTS test_qd50typi ENGINE=Replicated('/test/db/test_14', 's1', 'r1') ), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.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&) @ 0x0000000013db5399 4. /build/src/Databases/DatabaseReplicated.cpp:494: DB::DatabaseReplicated::tryConnectToZooKeeperAndInitDatabase(DB::LoadingStrictnessLevel) @ 0x0000000013d91155 5. /build/src/Databases/DatabaseReplicated.cpp:735: DB::DatabaseReplicated::beforeLoadingMetadata(std::shared_ptr, DB::LoadingStrictnessLevel) @ 0x0000000013d954d4 6. /build/src/Databases/TablesLoader.cpp:57: DB::TablesLoader::loadTablesAsync(std::unordered_set, std::hash>, std::equal_to>, std::allocator>>) @ 0x000000001490e734 7. /build/src/Interpreters/InterpreterCreateQuery.cpp:383: DB::InterpreterCreateQuery::createDatabase(DB::ASTCreateQuery&) @ 0x00000000148e8e14 8. /build/src/Interpreters/InterpreterCreateQuery.cpp:2351: DB::InterpreterCreateQuery::execute() @ 0x0000000014905a3a 9. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88dc9 10. /build/src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x0000000014c8ca7b 11. /build/src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000001686da12 12. /build/src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x0000000016870807 13. /build/src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x0000000016907e99 14. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 15. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 16. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 17. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 18. ? @ 0x00007fbc6213eac3 19. ? @ 0x00007fbc621d0850 2025.07.28 11:56:46.883715 [ 17611 ] {ba5198c8-c958-4d6e-9919-a7237fe5d171} DynamicQueryHandler: Code: 253. DB::Exception: Replica r1 of shard s1 of replicated database at /test/db/test_14 already exists. Replica host ID: '146b4357c08d:9000:2e9f5a5a-d01a-404b-9f39-a9efc39ca82f', current host ID: '146b4357c08d:9000:184ddfef-7c6d-4259-8e08-b0a8b9ec4eff'. (REPLICA_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.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&) @ 0x0000000013db5399 4. /build/src/Databases/DatabaseReplicated.cpp:494: DB::DatabaseReplicated::tryConnectToZooKeeperAndInitDatabase(DB::LoadingStrictnessLevel) @ 0x0000000013d91155 5. /build/src/Databases/DatabaseReplicated.cpp:735: DB::DatabaseReplicated::beforeLoadingMetadata(std::shared_ptr, DB::LoadingStrictnessLevel) @ 0x0000000013d954d4 6. /build/src/Databases/TablesLoader.cpp:57: DB::TablesLoader::loadTablesAsync(std::unordered_set, std::hash>, std::equal_to>, std::allocator>>) @ 0x000000001490e734 7. /build/src/Interpreters/InterpreterCreateQuery.cpp:383: DB::InterpreterCreateQuery::createDatabase(DB::ASTCreateQuery&) @ 0x00000000148e8e14 8. /build/src/Interpreters/InterpreterCreateQuery.cpp:2351: DB::InterpreterCreateQuery::execute() @ 0x0000000014905a3a 9. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88dc9 10. /build/src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x0000000014c8ca7b 11. /build/src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000001686da12 12. /build/src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x0000000016870807 13. /build/src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x0000000016907e99 14. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 15. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 16. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 17. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 18. ? @ 0x00007fbc6213eac3 19. ? @ 0x00007fbc621d0850 (version 25.3.6.10636.altinitytest (altinity build)) 2025.07.28 11:56:46.934269 [ 17306 ] {82c8ff46-01f8-45f8-8ca2-da11e78baf1e} executeQuery: Code: 253. DB::Exception: Replica r1 of shard s1 of replicated database at /test/db/test_14 already exists. Replica host ID: '146b4357c08d:9000:2e9f5a5a-d01a-404b-9f39-a9efc39ca82f', current host ID: '146b4357c08d:9000:6c09c9bd-7151-4eae-a91c-8df3ea2bf89d'. (REPLICA_ALREADY_EXISTS) (version 25.3.6.10636.altinitytest (altinity build)) (from [::1]:36280) (comment: 00010_quantiles_segfault.sql) (in query: CREATE DATABASE IF NOT EXISTS test_kdv2zwqb ENGINE=Replicated('/test/db/test_14', 's1', 'r1') ), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.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&) @ 0x0000000013db5399 4. /build/src/Databases/DatabaseReplicated.cpp:494: DB::DatabaseReplicated::tryConnectToZooKeeperAndInitDatabase(DB::LoadingStrictnessLevel) @ 0x0000000013d91155 5. /build/src/Databases/DatabaseReplicated.cpp:735: DB::DatabaseReplicated::beforeLoadingMetadata(std::shared_ptr, DB::LoadingStrictnessLevel) @ 0x0000000013d954d4 6. /build/src/Databases/TablesLoader.cpp:57: DB::TablesLoader::loadTablesAsync(std::unordered_set, std::hash>, std::equal_to>, std::allocator>>) @ 0x000000001490e734 7. /build/src/Interpreters/InterpreterCreateQuery.cpp:383: DB::InterpreterCreateQuery::createDatabase(DB::ASTCreateQuery&) @ 0x00000000148e8e14 8. /build/src/Interpreters/InterpreterCreateQuery.cpp:2351: DB::InterpreterCreateQuery::execute() @ 0x0000000014905a3a 9. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88dc9 10. /build/src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x0000000014c8ca7b 11. /build/src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000001686da12 12. /build/src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x0000000016870807 13. /build/src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x0000000016907e99 14. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 15. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 16. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 17. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 18. ? @ 0x00007fbc6213eac3 19. ? @ 0x00007fbc621d0850 2025.07.28 11:56:46.936683 [ 17306 ] {82c8ff46-01f8-45f8-8ca2-da11e78baf1e} DynamicQueryHandler: Code: 253. DB::Exception: Replica r1 of shard s1 of replicated database at /test/db/test_14 already exists. Replica host ID: '146b4357c08d:9000:2e9f5a5a-d01a-404b-9f39-a9efc39ca82f', current host ID: '146b4357c08d:9000:6c09c9bd-7151-4eae-a91c-8df3ea2bf89d'. (REPLICA_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.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&) @ 0x0000000013db5399 4. /build/src/Databases/DatabaseReplicated.cpp:494: DB::DatabaseReplicated::tryConnectToZooKeeperAndInitDatabase(DB::LoadingStrictnessLevel) @ 0x0000000013d91155 5. /build/src/Databases/DatabaseReplicated.cpp:735: DB::DatabaseReplicated::beforeLoadingMetadata(std::shared_ptr, DB::LoadingStrictnessLevel) @ 0x0000000013d954d4 6. /build/src/Databases/TablesLoader.cpp:57: DB::TablesLoader::loadTablesAsync(std::unordered_set, std::hash>, std::equal_to>, std::allocator>>) @ 0x000000001490e734 7. /build/src/Interpreters/InterpreterCreateQuery.cpp:383: DB::InterpreterCreateQuery::createDatabase(DB::ASTCreateQuery&) @ 0x00000000148e8e14 8. /build/src/Interpreters/InterpreterCreateQuery.cpp:2351: DB::InterpreterCreateQuery::execute() @ 0x0000000014905a3a 9. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88dc9 10. /build/src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x0000000014c8ca7b 11. /build/src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000001686da12 12. /build/src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x0000000016870807 13. /build/src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x0000000016907e99 14. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 15. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 16. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 17. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 18. ? @ 0x00007fbc6213eac3 19. ? @ 0x00007fbc621d0850 (version 25.3.6.10636.altinitytest (altinity build)) 2025.07.28 11:56:46.975118 [ 17611 ] {b335796f-1def-424a-8341-d5ba7151b9a7} executeQuery: Code: 253. DB::Exception: Replica r1 of shard s1 of replicated database at /test/db/test_14 already exists. Replica host ID: '146b4357c08d:9000:2e9f5a5a-d01a-404b-9f39-a9efc39ca82f', current host ID: '146b4357c08d:9000:06366c7e-f349-495f-8a39-5c9584b2304b'. (REPLICA_ALREADY_EXISTS) (version 25.3.6.10636.altinitytest (altinity build)) (from [::1]:36292) (comment: 01417_freeze_partition_verbose.sh) (in query: CREATE DATABASE IF NOT EXISTS test_n0f2c0p5 ENGINE=Replicated('/test/db/test_14', 's1', 'r1') ), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.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&) @ 0x0000000013db5399 4. /build/src/Databases/DatabaseReplicated.cpp:494: DB::DatabaseReplicated::tryConnectToZooKeeperAndInitDatabase(DB::LoadingStrictnessLevel) @ 0x0000000013d91155 5. /build/src/Databases/DatabaseReplicated.cpp:735: DB::DatabaseReplicated::beforeLoadingMetadata(std::shared_ptr, DB::LoadingStrictnessLevel) @ 0x0000000013d954d4 6. /build/src/Databases/TablesLoader.cpp:57: DB::TablesLoader::loadTablesAsync(std::unordered_set, std::hash>, std::equal_to>, std::allocator>>) @ 0x000000001490e734 7. /build/src/Interpreters/InterpreterCreateQuery.cpp:383: DB::InterpreterCreateQuery::createDatabase(DB::ASTCreateQuery&) @ 0x00000000148e8e14 8. /build/src/Interpreters/InterpreterCreateQuery.cpp:2351: DB::InterpreterCreateQuery::execute() @ 0x0000000014905a3a 9. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88dc9 10. /build/src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x0000000014c8ca7b 11. /build/src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000001686da12 12. /build/src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x0000000016870807 13. /build/src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x0000000016907e99 14. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 15. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 16. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 17. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 18. ? @ 0x00007fbc6213eac3 19. ? @ 0x00007fbc621d0850 2025.07.28 11:56:46.977066 [ 17611 ] {b335796f-1def-424a-8341-d5ba7151b9a7} DynamicQueryHandler: Code: 253. DB::Exception: Replica r1 of shard s1 of replicated database at /test/db/test_14 already exists. Replica host ID: '146b4357c08d:9000:2e9f5a5a-d01a-404b-9f39-a9efc39ca82f', current host ID: '146b4357c08d:9000:06366c7e-f349-495f-8a39-5c9584b2304b'. (REPLICA_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.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&) @ 0x0000000013db5399 4. /build/src/Databases/DatabaseReplicated.cpp:494: DB::DatabaseReplicated::tryConnectToZooKeeperAndInitDatabase(DB::LoadingStrictnessLevel) @ 0x0000000013d91155 5. /build/src/Databases/DatabaseReplicated.cpp:735: DB::DatabaseReplicated::beforeLoadingMetadata(std::shared_ptr, DB::LoadingStrictnessLevel) @ 0x0000000013d954d4 6. /build/src/Databases/TablesLoader.cpp:57: DB::TablesLoader::loadTablesAsync(std::unordered_set, std::hash>, std::equal_to>, std::allocator>>) @ 0x000000001490e734 7. /build/src/Interpreters/InterpreterCreateQuery.cpp:383: DB::InterpreterCreateQuery::createDatabase(DB::ASTCreateQuery&) @ 0x00000000148e8e14 8. /build/src/Interpreters/InterpreterCreateQuery.cpp:2351: DB::InterpreterCreateQuery::execute() @ 0x0000000014905a3a 9. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88dc9 10. /build/src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x0000000014c8ca7b 11. /build/src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000001686da12 12. /build/src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x0000000016870807 13. /build/src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x0000000016907e99 14. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 15. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 16. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 17. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 18. ? @ 0x00007fbc6213eac3 19. ? @ 0x00007fbc621d0850 (version 25.3.6.10636.altinitytest (altinity build)) 2025.07.28 11:56:47.028528 [ 17306 ] {e1e42cb1-f27c-4351-af42-9c0c94558785} executeQuery: Code: 253. DB::Exception: Replica r1 of shard s1 of replicated database at /test/db/test_14 already exists. Replica host ID: '146b4357c08d:9000:2e9f5a5a-d01a-404b-9f39-a9efc39ca82f', current host ID: '146b4357c08d:9000:6a73179c-5650-439d-860d-3c8707b563d2'. (REPLICA_ALREADY_EXISTS) (version 25.3.6.10636.altinitytest (altinity build)) (from [::1]:36308) (comment: 02099_sql_user_defined_functions_lambda.sql) (in query: CREATE DATABASE IF NOT EXISTS test_vflpqcq9 ENGINE=Replicated('/test/db/test_14', 's1', 'r1') ), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.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&) @ 0x0000000013db5399 4. /build/src/Databases/DatabaseReplicated.cpp:494: DB::DatabaseReplicated::tryConnectToZooKeeperAndInitDatabase(DB::LoadingStrictnessLevel) @ 0x0000000013d91155 5. /build/src/Databases/DatabaseReplicated.cpp:735: DB::DatabaseReplicated::beforeLoadingMetadata(std::shared_ptr, DB::LoadingStrictnessLevel) @ 0x0000000013d954d4 6. /build/src/Databases/TablesLoader.cpp:57: DB::TablesLoader::loadTablesAsync(std::unordered_set, std::hash>, std::equal_to>, std::allocator>>) @ 0x000000001490e734 7. /build/src/Interpreters/InterpreterCreateQuery.cpp:383: DB::InterpreterCreateQuery::createDatabase(DB::ASTCreateQuery&) @ 0x00000000148e8e14 8. /build/src/Interpreters/InterpreterCreateQuery.cpp:2351: DB::InterpreterCreateQuery::execute() @ 0x0000000014905a3a 9. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88dc9 10. /build/src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x0000000014c8ca7b 11. /build/src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000001686da12 12. /build/src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x0000000016870807 13. /build/src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x0000000016907e99 14. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 15. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 16. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 17. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 18. ? @ 0x00007fbc6213eac3 19. ? @ 0x00007fbc621d0850 2025.07.28 11:56:47.032252 [ 17306 ] {e1e42cb1-f27c-4351-af42-9c0c94558785} DynamicQueryHandler: Code: 253. DB::Exception: Replica r1 of shard s1 of replicated database at /test/db/test_14 already exists. Replica host ID: '146b4357c08d:9000:2e9f5a5a-d01a-404b-9f39-a9efc39ca82f', current host ID: '146b4357c08d:9000:6a73179c-5650-439d-860d-3c8707b563d2'. (REPLICA_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.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&) @ 0x0000000013db5399 4. /build/src/Databases/DatabaseReplicated.cpp:494: DB::DatabaseReplicated::tryConnectToZooKeeperAndInitDatabase(DB::LoadingStrictnessLevel) @ 0x0000000013d91155 5. /build/src/Databases/DatabaseReplicated.cpp:735: DB::DatabaseReplicated::beforeLoadingMetadata(std::shared_ptr, DB::LoadingStrictnessLevel) @ 0x0000000013d954d4 6. /build/src/Databases/TablesLoader.cpp:57: DB::TablesLoader::loadTablesAsync(std::unordered_set, std::hash>, std::equal_to>, std::allocator>>) @ 0x000000001490e734 7. /build/src/Interpreters/InterpreterCreateQuery.cpp:383: DB::InterpreterCreateQuery::createDatabase(DB::ASTCreateQuery&) @ 0x00000000148e8e14 8. /build/src/Interpreters/InterpreterCreateQuery.cpp:2351: DB::InterpreterCreateQuery::execute() @ 0x0000000014905a3a 9. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88dc9 10. /build/src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x0000000014c8ca7b 11. /build/src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000001686da12 12. /build/src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x0000000016870807 13. /build/src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x0000000016907e99 14. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 15. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 16. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 17. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 18. ? @ 0x00007fbc6213eac3 19. ? @ 0x00007fbc621d0850 (version 25.3.6.10636.altinitytest (altinity build)) 2025.07.28 11:56:47.093273 [ 17611 ] {5c49d1f3-99bf-435f-86f8-6aeb06580a98} executeQuery: Code: 253. DB::Exception: Replica r1 of shard s1 of replicated database at /test/db/test_14 already exists. Replica host ID: '146b4357c08d:9000:2e9f5a5a-d01a-404b-9f39-a9efc39ca82f', current host ID: '146b4357c08d:9000:2eca0126-80b5-4068-8542-325dc10feca6'. (REPLICA_ALREADY_EXISTS) (version 25.3.6.10636.altinitytest (altinity build)) (from [::1]:36312) (comment: 00052_group_by_in.sql) (in query: CREATE DATABASE IF NOT EXISTS test_zlwrg5cs ENGINE=Replicated('/test/db/test_14', 's1', 'r1') ), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.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&) @ 0x0000000013db5399 4. /build/src/Databases/DatabaseReplicated.cpp:494: DB::DatabaseReplicated::tryConnectToZooKeeperAndInitDatabase(DB::LoadingStrictnessLevel) @ 0x0000000013d91155 5. /build/src/Databases/DatabaseReplicated.cpp:735: DB::DatabaseReplicated::beforeLoadingMetadata(std::shared_ptr, DB::LoadingStrictnessLevel) @ 0x0000000013d954d4 6. /build/src/Databases/TablesLoader.cpp:57: DB::TablesLoader::loadTablesAsync(std::unordered_set, std::hash>, std::equal_to>, std::allocator>>) @ 0x000000001490e734 7. /build/src/Interpreters/InterpreterCreateQuery.cpp:383: DB::InterpreterCreateQuery::createDatabase(DB::ASTCreateQuery&) @ 0x00000000148e8e14 8. /build/src/Interpreters/InterpreterCreateQuery.cpp:2351: DB::InterpreterCreateQuery::execute() @ 0x0000000014905a3a 9. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88dc9 10. /build/src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x0000000014c8ca7b 11. /build/src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000001686da12 12. /build/src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x0000000016870807 13. /build/src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x0000000016907e99 14. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 15. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 16. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 17. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 18. ? @ 0x00007fbc6213eac3 19. ? @ 0x00007fbc621d0850 2025.07.28 11:56:47.141818 [ 17611 ] {5c49d1f3-99bf-435f-86f8-6aeb06580a98} DynamicQueryHandler: Code: 253. DB::Exception: Replica r1 of shard s1 of replicated database at /test/db/test_14 already exists. Replica host ID: '146b4357c08d:9000:2e9f5a5a-d01a-404b-9f39-a9efc39ca82f', current host ID: '146b4357c08d:9000:2eca0126-80b5-4068-8542-325dc10feca6'. (REPLICA_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.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&) @ 0x0000000013db5399 4. /build/src/Databases/DatabaseReplicated.cpp:494: DB::DatabaseReplicated::tryConnectToZooKeeperAndInitDatabase(DB::LoadingStrictnessLevel) @ 0x0000000013d91155 5. /build/src/Databases/DatabaseReplicated.cpp:735: DB::DatabaseReplicated::beforeLoadingMetadata(std::shared_ptr, DB::LoadingStrictnessLevel) @ 0x0000000013d954d4 6. /build/src/Databases/TablesLoader.cpp:57: DB::TablesLoader::loadTablesAsync(std::unordered_set, std::hash>, std::equal_to>, std::allocator>>) @ 0x000000001490e734 7. /build/src/Interpreters/InterpreterCreateQuery.cpp:383: DB::InterpreterCreateQuery::createDatabase(DB::ASTCreateQuery&) @ 0x00000000148e8e14 8. /build/src/Interpreters/InterpreterCreateQuery.cpp:2351: DB::InterpreterCreateQuery::execute() @ 0x0000000014905a3a 9. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88dc9 10. /build/src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x0000000014c8ca7b 11. /build/src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000001686da12 12. /build/src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x0000000016870807 13. /build/src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x0000000016907e99 14. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 15. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 16. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 17. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 18. ? @ 0x00007fbc6213eac3 19. ? @ 0x00007fbc621d0850 (version 25.3.6.10636.altinitytest (altinity build)) 2025.07.28 11:56:47.202735 [ 17306 ] {e2364da1-dd13-4674-9d5f-6562a092115f} executeQuery: Code: 253. DB::Exception: Replica r1 of shard s1 of replicated database at /test/db/test_14 already exists. Replica host ID: '146b4357c08d:9000:2e9f5a5a-d01a-404b-9f39-a9efc39ca82f', current host ID: '146b4357c08d:9000:beca698c-4f67-423e-839c-b4dd912ed1b0'. (REPLICA_ALREADY_EXISTS) (version 25.3.6.10636.altinitytest (altinity build)) (from [::1]:36322) (comment: 02405_avro_read_nested.sql) (in query: CREATE DATABASE IF NOT EXISTS test_zjp0eq4m ENGINE=Replicated('/test/db/test_14', 's1', 'r1') ), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.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&) @ 0x0000000013db5399 4. /build/src/Databases/DatabaseReplicated.cpp:494: DB::DatabaseReplicated::tryConnectToZooKeeperAndInitDatabase(DB::LoadingStrictnessLevel) @ 0x0000000013d91155 5. /build/src/Databases/DatabaseReplicated.cpp:735: DB::DatabaseReplicated::beforeLoadingMetadata(std::shared_ptr, DB::LoadingStrictnessLevel) @ 0x0000000013d954d4 6. /build/src/Databases/TablesLoader.cpp:57: DB::TablesLoader::loadTablesAsync(std::unordered_set, std::hash>, std::equal_to>, std::allocator>>) @ 0x000000001490e734 7. /build/src/Interpreters/InterpreterCreateQuery.cpp:383: DB::InterpreterCreateQuery::createDatabase(DB::ASTCreateQuery&) @ 0x00000000148e8e14 8. /build/src/Interpreters/InterpreterCreateQuery.cpp:2351: DB::InterpreterCreateQuery::execute() @ 0x0000000014905a3a 9. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88dc9 10. /build/src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x0000000014c8ca7b 11. /build/src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000001686da12 12. /build/src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x0000000016870807 13. /build/src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x0000000016907e99 14. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 15. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 16. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 17. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 18. ? @ 0x00007fbc6213eac3 19. ? @ 0x00007fbc621d0850 2025.07.28 11:56:47.205186 [ 17306 ] {e2364da1-dd13-4674-9d5f-6562a092115f} DynamicQueryHandler: Code: 253. DB::Exception: Replica r1 of shard s1 of replicated database at /test/db/test_14 already exists. Replica host ID: '146b4357c08d:9000:2e9f5a5a-d01a-404b-9f39-a9efc39ca82f', current host ID: '146b4357c08d:9000:beca698c-4f67-423e-839c-b4dd912ed1b0'. (REPLICA_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.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&) @ 0x0000000013db5399 4. /build/src/Databases/DatabaseReplicated.cpp:494: DB::DatabaseReplicated::tryConnectToZooKeeperAndInitDatabase(DB::LoadingStrictnessLevel) @ 0x0000000013d91155 5. /build/src/Databases/DatabaseReplicated.cpp:735: DB::DatabaseReplicated::beforeLoadingMetadata(std::shared_ptr, DB::LoadingStrictnessLevel) @ 0x0000000013d954d4 6. /build/src/Databases/TablesLoader.cpp:57: DB::TablesLoader::loadTablesAsync(std::unordered_set, std::hash>, std::equal_to>, std::allocator>>) @ 0x000000001490e734 7. /build/src/Interpreters/InterpreterCreateQuery.cpp:383: DB::InterpreterCreateQuery::createDatabase(DB::ASTCreateQuery&) @ 0x00000000148e8e14 8. /build/src/Interpreters/InterpreterCreateQuery.cpp:2351: DB::InterpreterCreateQuery::execute() @ 0x0000000014905a3a 9. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88dc9 10. /build/src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x0000000014c8ca7b 11. /build/src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000001686da12 12. /build/src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x0000000016870807 13. /build/src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x0000000016907e99 14. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 15. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 16. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 17. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 18. ? @ 0x00007fbc6213eac3 19. ? @ 0x00007fbc621d0850 (version 25.3.6.10636.altinitytest (altinity build)) 2025.07.28 11:56:47.282932 [ 3967 ] {} test_13.rmt2 (7f9b740d-015c-470e-8cc6-8ba33be0dc63): auto DB::StorageReplicatedMergeTree::processQueueEntry(ReplicatedMergeTreeQueue::SelectedEntryPtr)::(anonymous class)::operator()(LogEntryPtr &) const: Code: 86. DB::HTTPException: Received error from remote server http://146b4357c08d:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Ftest%2F01165%2Ftest_13%2Frmt%2Freplicas%2F1&part=20250728_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.6.10636.altinitytest (altinity build)) '. (RECEIVED_ERROR_FROM_REMOTE_IO_SERVER), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.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 const&, int&&, String const&, unsigned long&&, String const&) @ 0x000000000feda8d9 4. /build/src/IO/HTTPCommon.cpp:104: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x000000000feda6e2 5. /build/src/IO/HTTPCommon.cpp:93: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x000000000feda537 6. /build/src/IO/ReadWriteBufferFromHTTP.cpp:277: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x000000001184a4c4 7. /build/src/IO/ReadWriteBufferFromHTTP.cpp:285: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x000000001184a615 8. /build/src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x000000001184ae59 9. /build/src/IO/ReadWriteBufferFromHTTP.cpp:472: void std::__function::__policy_invoker::__call_impl[abi:se190107]>(std::__function::__policy_storage const*) @ 0x000000001184cedd 10. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001184858b 11. /build/src/IO/ReadWriteBufferFromHTTP.cpp:465: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x000000001184bf0b 12. /build/src/IO/ReadBuffer.h:60: DB::ReadBuffer::next() @ 0x000000000a148c7b 13. /build/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) @ 0x0000000011849fb2 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]>&)>&, 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&) @ 0x0000000011841980 15. /build/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) @ 0x000000001621208e 16. /build/src/Storages/StorageReplicatedMergeTree.cpp:5228: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl[abi:se190107] const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000015f9a5fe 17. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000015ed8bfd 18. /build/src/Storages/StorageReplicatedMergeTree.cpp:2514: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x0000000015ec9aab 19. /build/src/Storages/StorageReplicatedMergeTree.cpp:2349: DB::StorageReplicatedMergeTree::executeLogEntry(DB::ReplicatedMergeTreeLogEntry&) @ 0x0000000015eba91b 20. /build/src/Storages/StorageReplicatedMergeTree.cpp:3876: bool std::__function::__policy_invoker&)>::__call_impl[abi:se190107])::$_1, bool (std::shared_ptr&)>>(std::__function::__policy_storage const*, std::shared_ptr&) @ 0x0000000015f9837e 21. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000165d6fc3 22. /build/src/Storages/StorageReplicatedMergeTree.cpp:3872: DB::StorageReplicatedMergeTree::processQueueEntry(std::shared_ptr) @ 0x0000000015efc18a 23. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001624c1b2 24. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000162f9c70 25. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x00000000162fa55a 26. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc6653 27. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000000fccc4c3 28. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc3d92 29. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fcca080 30. ? @ 0x00007fbc6213eac3 31. ? @ 0x00007fbc621d0850 (version 25.3.6.10636.altinitytest (altinity build)) 2025.07.28 11:56:47.287318 [ 17611 ] {66ccd40e-a08c-48c5-ac8e-06355de745df} executeQuery: Code: 253. DB::Exception: Replica r1 of shard s1 of replicated database at /test/db/test_14 already exists. Replica host ID: '146b4357c08d:9000:2e9f5a5a-d01a-404b-9f39-a9efc39ca82f', current host ID: '146b4357c08d:9000:ffce0715-d4ee-488f-9c44-63e703571091'. (REPLICA_ALREADY_EXISTS) (version 25.3.6.10636.altinitytest (altinity build)) (from [::1]:36324) (comment: 03128_system_unload_primary_key.sql) (in query: CREATE DATABASE IF NOT EXISTS test_2vak2lb1 ENGINE=Replicated('/test/db/test_14', 's1', 'r1') ), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.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&) @ 0x0000000013db5399 4. /build/src/Databases/DatabaseReplicated.cpp:494: DB::DatabaseReplicated::tryConnectToZooKeeperAndInitDatabase(DB::LoadingStrictnessLevel) @ 0x0000000013d91155 5. /build/src/Databases/DatabaseReplicated.cpp:735: DB::DatabaseReplicated::beforeLoadingMetadata(std::shared_ptr, DB::LoadingStrictnessLevel) @ 0x0000000013d954d4 6. /build/src/Databases/TablesLoader.cpp:57: DB::TablesLoader::loadTablesAsync(std::unordered_set, std::hash>, std::equal_to>, std::allocator>>) @ 0x000000001490e734 7. /build/src/Interpreters/InterpreterCreateQuery.cpp:383: DB::InterpreterCreateQuery::createDatabase(DB::ASTCreateQuery&) @ 0x00000000148e8e14 8. /build/src/Interpreters/InterpreterCreateQuery.cpp:2351: DB::InterpreterCreateQuery::execute() @ 0x0000000014905a3a 9. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88dc9 10. /build/src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x0000000014c8ca7b 11. /build/src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000001686da12 12. /build/src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x0000000016870807 13. /build/src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x0000000016907e99 14. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 15. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 16. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 17. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 18. ? @ 0x00007fbc6213eac3 19. ? @ 0x00007fbc621d0850 2025.07.28 11:56:47.299793 [ 17611 ] {66ccd40e-a08c-48c5-ac8e-06355de745df} DynamicQueryHandler: Code: 253. DB::Exception: Replica r1 of shard s1 of replicated database at /test/db/test_14 already exists. Replica host ID: '146b4357c08d:9000:2e9f5a5a-d01a-404b-9f39-a9efc39ca82f', current host ID: '146b4357c08d:9000:ffce0715-d4ee-488f-9c44-63e703571091'. (REPLICA_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.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&) @ 0x0000000013db5399 4. /build/src/Databases/DatabaseReplicated.cpp:494: DB::DatabaseReplicated::tryConnectToZooKeeperAndInitDatabase(DB::LoadingStrictnessLevel) @ 0x0000000013d91155 5. /build/src/Databases/DatabaseReplicated.cpp:735: DB::DatabaseReplicated::beforeLoadingMetadata(std::shared_ptr, DB::LoadingStrictnessLevel) @ 0x0000000013d954d4 6. /build/src/Databases/TablesLoader.cpp:57: DB::TablesLoader::loadTablesAsync(std::unordered_set, std::hash>, std::equal_to>, std::allocator>>) @ 0x000000001490e734 7. /build/src/Interpreters/InterpreterCreateQuery.cpp:383: DB::InterpreterCreateQuery::createDatabase(DB::ASTCreateQuery&) @ 0x00000000148e8e14 8. /build/src/Interpreters/InterpreterCreateQuery.cpp:2351: DB::InterpreterCreateQuery::execute() @ 0x0000000014905a3a 9. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88dc9 10. /build/src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x0000000014c8ca7b 11. /build/src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000001686da12 12. /build/src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x0000000016870807 13. /build/src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x0000000016907e99 14. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 15. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 16. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 17. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 18. ? @ 0x00007fbc6213eac3 19. ? @ 0x00007fbc621d0850 (version 25.3.6.10636.altinitytest (altinity build)) 2025.07.28 11:56:47.386692 [ 17306 ] {09eff778-b777-4f17-818d-d7fa56be5f15} executeQuery: Code: 253. DB::Exception: Replica r1 of shard s1 of replicated database at /test/db/test_14 already exists. Replica host ID: '146b4357c08d:9000:2e9f5a5a-d01a-404b-9f39-a9efc39ca82f', current host ID: '146b4357c08d:9000:533e6250-13ab-4412-b3de-a7d79530ca34'. (REPLICA_ALREADY_EXISTS) (version 25.3.6.10636.altinitytest (altinity build)) (from [::1]:36340) (comment: 01225_show_create_table_from_dictionary.sql) (in query: CREATE DATABASE IF NOT EXISTS test_qyrcvgy9 ENGINE=Replicated('/test/db/test_14', 's1', 'r1') ), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.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&) @ 0x0000000013db5399 4. /build/src/Databases/DatabaseReplicated.cpp:494: DB::DatabaseReplicated::tryConnectToZooKeeperAndInitDatabase(DB::LoadingStrictnessLevel) @ 0x0000000013d91155 5. /build/src/Databases/DatabaseReplicated.cpp:735: DB::DatabaseReplicated::beforeLoadingMetadata(std::shared_ptr, DB::LoadingStrictnessLevel) @ 0x0000000013d954d4 6. /build/src/Databases/TablesLoader.cpp:57: DB::TablesLoader::loadTablesAsync(std::unordered_set, std::hash>, std::equal_to>, std::allocator>>) @ 0x000000001490e734 7. /build/src/Interpreters/InterpreterCreateQuery.cpp:383: DB::InterpreterCreateQuery::createDatabase(DB::ASTCreateQuery&) @ 0x00000000148e8e14 8. /build/src/Interpreters/InterpreterCreateQuery.cpp:2351: DB::InterpreterCreateQuery::execute() @ 0x0000000014905a3a 9. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88dc9 10. /build/src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x0000000014c8ca7b 11. /build/src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000001686da12 12. /build/src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x0000000016870807 13. /build/src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x0000000016907e99 14. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 15. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 16. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 17. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 18. ? @ 0x00007fbc6213eac3 19. ? @ 0x00007fbc621d0850 2025.07.28 11:56:47.388155 [ 17306 ] {09eff778-b777-4f17-818d-d7fa56be5f15} DynamicQueryHandler: Code: 253. DB::Exception: Replica r1 of shard s1 of replicated database at /test/db/test_14 already exists. Replica host ID: '146b4357c08d:9000:2e9f5a5a-d01a-404b-9f39-a9efc39ca82f', current host ID: '146b4357c08d:9000:533e6250-13ab-4412-b3de-a7d79530ca34'. (REPLICA_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.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&) @ 0x0000000013db5399 4. /build/src/Databases/DatabaseReplicated.cpp:494: DB::DatabaseReplicated::tryConnectToZooKeeperAndInitDatabase(DB::LoadingStrictnessLevel) @ 0x0000000013d91155 5. /build/src/Databases/DatabaseReplicated.cpp:735: DB::DatabaseReplicated::beforeLoadingMetadata(std::shared_ptr, DB::LoadingStrictnessLevel) @ 0x0000000013d954d4 6. /build/src/Databases/TablesLoader.cpp:57: DB::TablesLoader::loadTablesAsync(std::unordered_set, std::hash>, std::equal_to>, std::allocator>>) @ 0x000000001490e734 7. /build/src/Interpreters/InterpreterCreateQuery.cpp:383: DB::InterpreterCreateQuery::createDatabase(DB::ASTCreateQuery&) @ 0x00000000148e8e14 8. /build/src/Interpreters/InterpreterCreateQuery.cpp:2351: DB::InterpreterCreateQuery::execute() @ 0x0000000014905a3a 9. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88dc9 10. /build/src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x0000000014c8ca7b 11. /build/src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000001686da12 12. /build/src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x0000000016870807 13. /build/src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x0000000016907e99 14. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 15. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 16. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 17. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 18. ? @ 0x00007fbc6213eac3 19. ? @ 0x00007fbc621d0850 (version 25.3.6.10636.altinitytest (altinity build)) 2025.07.28 11:56:47.504299 [ 17611 ] {5c4f9429-63df-4272-b839-48e64b6d5654} executeQuery: Code: 253. DB::Exception: Replica r1 of shard s1 of replicated database at /test/db/test_14 already exists. Replica host ID: '146b4357c08d:9000:2e9f5a5a-d01a-404b-9f39-a9efc39ca82f', current host ID: '146b4357c08d:9000:aedbb453-e912-42f6-9e3b-d785bab65d4d'. (REPLICA_ALREADY_EXISTS) (version 25.3.6.10636.altinitytest (altinity build)) (from [::1]:36350) (comment: 00084_external_aggregation.sql) (in query: CREATE DATABASE IF NOT EXISTS test_qtv3tex5 ENGINE=Replicated('/test/db/test_14', 's1', 'r1') ), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.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&) @ 0x0000000013db5399 4. /build/src/Databases/DatabaseReplicated.cpp:494: DB::DatabaseReplicated::tryConnectToZooKeeperAndInitDatabase(DB::LoadingStrictnessLevel) @ 0x0000000013d91155 5. /build/src/Databases/DatabaseReplicated.cpp:735: DB::DatabaseReplicated::beforeLoadingMetadata(std::shared_ptr, DB::LoadingStrictnessLevel) @ 0x0000000013d954d4 6. /build/src/Databases/TablesLoader.cpp:57: DB::TablesLoader::loadTablesAsync(std::unordered_set, std::hash>, std::equal_to>, std::allocator>>) @ 0x000000001490e734 7. /build/src/Interpreters/InterpreterCreateQuery.cpp:383: DB::InterpreterCreateQuery::createDatabase(DB::ASTCreateQuery&) @ 0x00000000148e8e14 8. /build/src/Interpreters/InterpreterCreateQuery.cpp:2351: DB::InterpreterCreateQuery::execute() @ 0x0000000014905a3a 9. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88dc9 10. /build/src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x0000000014c8ca7b 11. /build/src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000001686da12 12. /build/src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x0000000016870807 13. /build/src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x0000000016907e99 14. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 15. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 16. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 17. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 18. ? @ 0x00007fbc6213eac3 19. ? @ 0x00007fbc621d0850 2025.07.28 11:56:47.506206 [ 17611 ] {5c4f9429-63df-4272-b839-48e64b6d5654} DynamicQueryHandler: Code: 253. DB::Exception: Replica r1 of shard s1 of replicated database at /test/db/test_14 already exists. Replica host ID: '146b4357c08d:9000:2e9f5a5a-d01a-404b-9f39-a9efc39ca82f', current host ID: '146b4357c08d:9000:aedbb453-e912-42f6-9e3b-d785bab65d4d'. (REPLICA_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.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&) @ 0x0000000013db5399 4. /build/src/Databases/DatabaseReplicated.cpp:494: DB::DatabaseReplicated::tryConnectToZooKeeperAndInitDatabase(DB::LoadingStrictnessLevel) @ 0x0000000013d91155 5. /build/src/Databases/DatabaseReplicated.cpp:735: DB::DatabaseReplicated::beforeLoadingMetadata(std::shared_ptr, DB::LoadingStrictnessLevel) @ 0x0000000013d954d4 6. /build/src/Databases/TablesLoader.cpp:57: DB::TablesLoader::loadTablesAsync(std::unordered_set, std::hash>, std::equal_to>, std::allocator>>) @ 0x000000001490e734 7. /build/src/Interpreters/InterpreterCreateQuery.cpp:383: DB::InterpreterCreateQuery::createDatabase(DB::ASTCreateQuery&) @ 0x00000000148e8e14 8. /build/src/Interpreters/InterpreterCreateQuery.cpp:2351: DB::InterpreterCreateQuery::execute() @ 0x0000000014905a3a 9. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88dc9 10. /build/src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x0000000014c8ca7b 11. /build/src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000001686da12 12. /build/src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x0000000016870807 13. /build/src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x0000000016907e99 14. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 15. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 16. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 17. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 18. ? @ 0x00007fbc6213eac3 19. ? @ 0x00007fbc621d0850 (version 25.3.6.10636.altinitytest (altinity build)) 2025.07.28 11:56:47.516647 [ 3976 ] {} test_13.rmt2 (7f9b740d-015c-470e-8cc6-8ba33be0dc63): auto DB::StorageReplicatedMergeTree::processQueueEntry(ReplicatedMergeTreeQueue::SelectedEntryPtr)::(anonymous class)::operator()(LogEntryPtr &) const: Code: 86. DB::HTTPException: Received error from remote server http://146b4357c08d:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Ftest%2F01165%2Ftest_13%2Frmt%2Freplicas%2F1&part=20250728_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.6.10636.altinitytest (altinity build)) '. (RECEIVED_ERROR_FROM_REMOTE_IO_SERVER), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.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 const&, int&&, String const&, unsigned long&&, String const&) @ 0x000000000feda8d9 4. /build/src/IO/HTTPCommon.cpp:104: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x000000000feda6e2 5. /build/src/IO/HTTPCommon.cpp:93: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x000000000feda537 6. /build/src/IO/ReadWriteBufferFromHTTP.cpp:277: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x000000001184a4c4 7. /build/src/IO/ReadWriteBufferFromHTTP.cpp:285: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x000000001184a615 8. /build/src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x000000001184ae59 9. /build/src/IO/ReadWriteBufferFromHTTP.cpp:472: void std::__function::__policy_invoker::__call_impl[abi:se190107]>(std::__function::__policy_storage const*) @ 0x000000001184cedd 10. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001184858b 11. /build/src/IO/ReadWriteBufferFromHTTP.cpp:465: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x000000001184bf0b 12. /build/src/IO/ReadBuffer.h:60: DB::ReadBuffer::next() @ 0x000000000a148c7b 13. /build/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) @ 0x0000000011849fb2 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]>&)>&, 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&) @ 0x0000000011841980 15. /build/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) @ 0x000000001621208e 16. /build/src/Storages/StorageReplicatedMergeTree.cpp:5228: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl[abi:se190107] const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000015f9a5fe 17. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000015ed8bfd 18. /build/src/Storages/StorageReplicatedMergeTree.cpp:2514: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x0000000015ec9aab 19. /build/src/Storages/StorageReplicatedMergeTree.cpp:2349: DB::StorageReplicatedMergeTree::executeLogEntry(DB::ReplicatedMergeTreeLogEntry&) @ 0x0000000015eba91b 20. /build/src/Storages/StorageReplicatedMergeTree.cpp:3876: bool std::__function::__policy_invoker&)>::__call_impl[abi:se190107])::$_1, bool (std::shared_ptr&)>>(std::__function::__policy_storage const*, std::shared_ptr&) @ 0x0000000015f9837e 21. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000165d6fc3 22. /build/src/Storages/StorageReplicatedMergeTree.cpp:3872: DB::StorageReplicatedMergeTree::processQueueEntry(std::shared_ptr) @ 0x0000000015efc18a 23. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001624c1b2 24. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000162f9c70 25. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x00000000162fa55a 26. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc6653 27. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000000fccc4c3 28. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc3d92 29. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fcca080 30. ? @ 0x00007fbc6213eac3 31. ? @ 0x00007fbc621d0850 (version 25.3.6.10636.altinitytest (altinity build)) 2025.07.28 11:56:47.557791 [ 17371 ] {f993d97b-d00d-4c73-a5ef-c6007bdfdadc} executeQuery: Code: 253. DB::Exception: Replica r1 of shard s1 of replicated database at /test/db/test_14 already exists. Replica host ID: '146b4357c08d:9000:2e9f5a5a-d01a-404b-9f39-a9efc39ca82f', current host ID: '146b4357c08d:9000:c2d38665-0872-4732-abbd-939a67b06ad9'. (REPLICA_ALREADY_EXISTS) (version 25.3.6.10636.altinitytest (altinity build)) (from [::1]:36354) (comment: 02494_query_cache_udf_sql.sql) (in query: CREATE DATABASE IF NOT EXISTS test_mhcjlhcw ENGINE=Replicated('/test/db/test_14', 's1', 'r1') ), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.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&) @ 0x0000000013db5399 4. /build/src/Databases/DatabaseReplicated.cpp:494: DB::DatabaseReplicated::tryConnectToZooKeeperAndInitDatabase(DB::LoadingStrictnessLevel) @ 0x0000000013d91155 5. /build/src/Databases/DatabaseReplicated.cpp:735: DB::DatabaseReplicated::beforeLoadingMetadata(std::shared_ptr, DB::LoadingStrictnessLevel) @ 0x0000000013d954d4 6. /build/src/Databases/TablesLoader.cpp:57: DB::TablesLoader::loadTablesAsync(std::unordered_set, std::hash>, std::equal_to>, std::allocator>>) @ 0x000000001490e734 7. /build/src/Interpreters/InterpreterCreateQuery.cpp:383: DB::InterpreterCreateQuery::createDatabase(DB::ASTCreateQuery&) @ 0x00000000148e8e14 8. /build/src/Interpreters/InterpreterCreateQuery.cpp:2351: DB::InterpreterCreateQuery::execute() @ 0x0000000014905a3a 9. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88dc9 10. /build/src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x0000000014c8ca7b 11. /build/src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000001686da12 12. /build/src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x0000000016870807 13. /build/src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x0000000016907e99 14. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 15. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 16. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 17. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 18. ? @ 0x00007fbc6213eac3 19. ? @ 0x00007fbc621d0850 2025.07.28 11:56:47.580561 [ 17371 ] {f993d97b-d00d-4c73-a5ef-c6007bdfdadc} DynamicQueryHandler: Code: 253. DB::Exception: Replica r1 of shard s1 of replicated database at /test/db/test_14 already exists. Replica host ID: '146b4357c08d:9000:2e9f5a5a-d01a-404b-9f39-a9efc39ca82f', current host ID: '146b4357c08d:9000:c2d38665-0872-4732-abbd-939a67b06ad9'. (REPLICA_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.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&) @ 0x0000000013db5399 4. /build/src/Databases/DatabaseReplicated.cpp:494: DB::DatabaseReplicated::tryConnectToZooKeeperAndInitDatabase(DB::LoadingStrictnessLevel) @ 0x0000000013d91155 5. /build/src/Databases/DatabaseReplicated.cpp:735: DB::DatabaseReplicated::beforeLoadingMetadata(std::shared_ptr, DB::LoadingStrictnessLevel) @ 0x0000000013d954d4 6. /build/src/Databases/TablesLoader.cpp:57: DB::TablesLoader::loadTablesAsync(std::unordered_set, std::hash>, std::equal_to>, std::allocator>>) @ 0x000000001490e734 7. /build/src/Interpreters/InterpreterCreateQuery.cpp:383: DB::InterpreterCreateQuery::createDatabase(DB::ASTCreateQuery&) @ 0x00000000148e8e14 8. /build/src/Interpreters/InterpreterCreateQuery.cpp:2351: DB::InterpreterCreateQuery::execute() @ 0x0000000014905a3a 9. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88dc9 10. /build/src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x0000000014c8ca7b 11. /build/src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000001686da12 12. /build/src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x0000000016870807 13. /build/src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x0000000016907e99 14. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 15. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 16. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 17. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 18. ? @ 0x00007fbc6213eac3 19. ? @ 0x00007fbc621d0850 (version 25.3.6.10636.altinitytest (altinity build)) 2025.07.28 11:56:47.634926 [ 3283 ] {cfbe8898-5886-46c9-89f8-86575e6d92ae} executeQuery: Code: 253. DB::Exception: Replica r1 of shard s1 of replicated database at /test/db/test_14 already exists. Replica host ID: '146b4357c08d:9000:2e9f5a5a-d01a-404b-9f39-a9efc39ca82f', current host ID: '146b4357c08d:9000:75f430ce-179d-4965-95a8-49302bad6e25'. (REPLICA_ALREADY_EXISTS) (version 25.3.6.10636.altinitytest (altinity build)) (from [::1]:36368) (comment: 01280_ttl_where_group_by_negative.sql) (in query: CREATE DATABASE IF NOT EXISTS test_6mcy7b3a ENGINE=Replicated('/test/db/test_14', 's1', 'r1') ), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.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&) @ 0x0000000013db5399 4. /build/src/Databases/DatabaseReplicated.cpp:494: DB::DatabaseReplicated::tryConnectToZooKeeperAndInitDatabase(DB::LoadingStrictnessLevel) @ 0x0000000013d91155 5. /build/src/Databases/DatabaseReplicated.cpp:735: DB::DatabaseReplicated::beforeLoadingMetadata(std::shared_ptr, DB::LoadingStrictnessLevel) @ 0x0000000013d954d4 6. /build/src/Databases/TablesLoader.cpp:57: DB::TablesLoader::loadTablesAsync(std::unordered_set, std::hash>, std::equal_to>, std::allocator>>) @ 0x000000001490e734 7. /build/src/Interpreters/InterpreterCreateQuery.cpp:383: DB::InterpreterCreateQuery::createDatabase(DB::ASTCreateQuery&) @ 0x00000000148e8e14 8. /build/src/Interpreters/InterpreterCreateQuery.cpp:2351: DB::InterpreterCreateQuery::execute() @ 0x0000000014905a3a 9. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88dc9 10. /build/src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x0000000014c8ca7b 11. /build/src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000001686da12 12. /build/src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x0000000016870807 13. /build/src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x0000000016907e99 14. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 15. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 16. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 17. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 18. ? @ 0x00007fbc6213eac3 19. ? @ 0x00007fbc621d0850 2025.07.28 11:56:47.636456 [ 3283 ] {cfbe8898-5886-46c9-89f8-86575e6d92ae} DynamicQueryHandler: Code: 253. DB::Exception: Replica r1 of shard s1 of replicated database at /test/db/test_14 already exists. Replica host ID: '146b4357c08d:9000:2e9f5a5a-d01a-404b-9f39-a9efc39ca82f', current host ID: '146b4357c08d:9000:75f430ce-179d-4965-95a8-49302bad6e25'. (REPLICA_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.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&) @ 0x0000000013db5399 4. /build/src/Databases/DatabaseReplicated.cpp:494: DB::DatabaseReplicated::tryConnectToZooKeeperAndInitDatabase(DB::LoadingStrictnessLevel) @ 0x0000000013d91155 5. /build/src/Databases/DatabaseReplicated.cpp:735: DB::DatabaseReplicated::beforeLoadingMetadata(std::shared_ptr, DB::LoadingStrictnessLevel) @ 0x0000000013d954d4 6. /build/src/Databases/TablesLoader.cpp:57: DB::TablesLoader::loadTablesAsync(std::unordered_set, std::hash>, std::equal_to>, std::allocator>>) @ 0x000000001490e734 7. /build/src/Interpreters/InterpreterCreateQuery.cpp:383: DB::InterpreterCreateQuery::createDatabase(DB::ASTCreateQuery&) @ 0x00000000148e8e14 8. /build/src/Interpreters/InterpreterCreateQuery.cpp:2351: DB::InterpreterCreateQuery::execute() @ 0x0000000014905a3a 9. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88dc9 10. /build/src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x0000000014c8ca7b 11. /build/src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000001686da12 12. /build/src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x0000000016870807 13. /build/src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x0000000016907e99 14. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 15. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 16. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 17. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 18. ? @ 0x00007fbc6213eac3 19. ? @ 0x00007fbc621d0850 (version 25.3.6.10636.altinitytest (altinity build)) 2025.07.28 11:56:47.670483 [ 17306 ] {8ba05376-57cf-4e80-a487-9c70abd0d3ba} executeQuery: Code: 253. DB::Exception: Replica r1 of shard s1 of replicated database at /test/db/test_14 already exists. Replica host ID: '146b4357c08d:9000:2e9f5a5a-d01a-404b-9f39-a9efc39ca82f', current host ID: '146b4357c08d:9000:9b0e3cd7-6b14-4740-b700-20a5c0a8df89'. (REPLICA_ALREADY_EXISTS) (version 25.3.6.10636.altinitytest (altinity build)) (from [::1]:36382) (comment: 02014_query_parameters.sh) (in query: CREATE DATABASE IF NOT EXISTS test_4todb35r ENGINE=Replicated('/test/db/test_14', 's1', 'r1') ), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.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&) @ 0x0000000013db5399 4. /build/src/Databases/DatabaseReplicated.cpp:494: DB::DatabaseReplicated::tryConnectToZooKeeperAndInitDatabase(DB::LoadingStrictnessLevel) @ 0x0000000013d91155 5. /build/src/Databases/DatabaseReplicated.cpp:735: DB::DatabaseReplicated::beforeLoadingMetadata(std::shared_ptr, DB::LoadingStrictnessLevel) @ 0x0000000013d954d4 6. /build/src/Databases/TablesLoader.cpp:57: DB::TablesLoader::loadTablesAsync(std::unordered_set, std::hash>, std::equal_to>, std::allocator>>) @ 0x000000001490e734 7. /build/src/Interpreters/InterpreterCreateQuery.cpp:383: DB::InterpreterCreateQuery::createDatabase(DB::ASTCreateQuery&) @ 0x00000000148e8e14 8. /build/src/Interpreters/InterpreterCreateQuery.cpp:2351: DB::InterpreterCreateQuery::execute() @ 0x0000000014905a3a 9. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88dc9 10. /build/src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x0000000014c8ca7b 11. /build/src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000001686da12 12. /build/src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x0000000016870807 13. /build/src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x0000000016907e99 14. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 15. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 16. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 17. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 18. ? @ 0x00007fbc6213eac3 19. ? @ 0x00007fbc621d0850 2025.07.28 11:56:47.671765 [ 17306 ] {8ba05376-57cf-4e80-a487-9c70abd0d3ba} DynamicQueryHandler: Code: 253. DB::Exception: Replica r1 of shard s1 of replicated database at /test/db/test_14 already exists. Replica host ID: '146b4357c08d:9000:2e9f5a5a-d01a-404b-9f39-a9efc39ca82f', current host ID: '146b4357c08d:9000:9b0e3cd7-6b14-4740-b700-20a5c0a8df89'. (REPLICA_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.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&) @ 0x0000000013db5399 4. /build/src/Databases/DatabaseReplicated.cpp:494: DB::DatabaseReplicated::tryConnectToZooKeeperAndInitDatabase(DB::LoadingStrictnessLevel) @ 0x0000000013d91155 5. /build/src/Databases/DatabaseReplicated.cpp:735: DB::DatabaseReplicated::beforeLoadingMetadata(std::shared_ptr, DB::LoadingStrictnessLevel) @ 0x0000000013d954d4 6. /build/src/Databases/TablesLoader.cpp:57: DB::TablesLoader::loadTablesAsync(std::unordered_set, std::hash>, std::equal_to>, std::allocator>>) @ 0x000000001490e734 7. /build/src/Interpreters/InterpreterCreateQuery.cpp:383: DB::InterpreterCreateQuery::createDatabase(DB::ASTCreateQuery&) @ 0x00000000148e8e14 8. /build/src/Interpreters/InterpreterCreateQuery.cpp:2351: DB::InterpreterCreateQuery::execute() @ 0x0000000014905a3a 9. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88dc9 10. /build/src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x0000000014c8ca7b 11. /build/src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000001686da12 12. /build/src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x0000000016870807 13. /build/src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x0000000016907e99 14. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 15. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 16. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 17. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 18. ? @ 0x00007fbc6213eac3 19. ? @ 0x00007fbc621d0850 (version 25.3.6.10636.altinitytest (altinity build)) 2025.07.28 11:56:47.746702 [ 3283 ] {eed13cd9-d9cc-4295-996a-2efd7f4393d5} executeQuery: Code: 253. DB::Exception: Replica r1 of shard s1 of replicated database at /test/db/test_14 already exists. Replica host ID: '146b4357c08d:9000:2e9f5a5a-d01a-404b-9f39-a9efc39ca82f', current host ID: '146b4357c08d:9000:e97fd899-270a-4764-b7c3-e3c3603f4b50'. (REPLICA_ALREADY_EXISTS) (version 25.3.6.10636.altinitytest (altinity build)) (from [::1]:36388) (comment: 03172_system_detached_tables_no_loop.sql) (in query: CREATE DATABASE IF NOT EXISTS test_wb062sp6 ENGINE=Replicated('/test/db/test_14', 's1', 'r1') ), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.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&) @ 0x0000000013db5399 4. /build/src/Databases/DatabaseReplicated.cpp:494: DB::DatabaseReplicated::tryConnectToZooKeeperAndInitDatabase(DB::LoadingStrictnessLevel) @ 0x0000000013d91155 5. /build/src/Databases/DatabaseReplicated.cpp:735: DB::DatabaseReplicated::beforeLoadingMetadata(std::shared_ptr, DB::LoadingStrictnessLevel) @ 0x0000000013d954d4 6. /build/src/Databases/TablesLoader.cpp:57: DB::TablesLoader::loadTablesAsync(std::unordered_set, std::hash>, std::equal_to>, std::allocator>>) @ 0x000000001490e734 7. /build/src/Interpreters/InterpreterCreateQuery.cpp:383: DB::InterpreterCreateQuery::createDatabase(DB::ASTCreateQuery&) @ 0x00000000148e8e14 8. /build/src/Interpreters/InterpreterCreateQuery.cpp:2351: DB::InterpreterCreateQuery::execute() @ 0x0000000014905a3a 9. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88dc9 10. /build/src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x0000000014c8ca7b 11. /build/src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000001686da12 12. /build/src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x0000000016870807 13. /build/src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x0000000016907e99 14. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 15. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 16. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 17. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 18. ? @ 0x00007fbc6213eac3 19. ? @ 0x00007fbc621d0850 2025.07.28 11:56:47.748900 [ 3283 ] {eed13cd9-d9cc-4295-996a-2efd7f4393d5} DynamicQueryHandler: Code: 253. DB::Exception: Replica r1 of shard s1 of replicated database at /test/db/test_14 already exists. Replica host ID: '146b4357c08d:9000:2e9f5a5a-d01a-404b-9f39-a9efc39ca82f', current host ID: '146b4357c08d:9000:e97fd899-270a-4764-b7c3-e3c3603f4b50'. (REPLICA_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.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&) @ 0x0000000013db5399 4. /build/src/Databases/DatabaseReplicated.cpp:494: DB::DatabaseReplicated::tryConnectToZooKeeperAndInitDatabase(DB::LoadingStrictnessLevel) @ 0x0000000013d91155 5. /build/src/Databases/DatabaseReplicated.cpp:735: DB::DatabaseReplicated::beforeLoadingMetadata(std::shared_ptr, DB::LoadingStrictnessLevel) @ 0x0000000013d954d4 6. /build/src/Databases/TablesLoader.cpp:57: DB::TablesLoader::loadTablesAsync(std::unordered_set, std::hash>, std::equal_to>, std::allocator>>) @ 0x000000001490e734 7. /build/src/Interpreters/InterpreterCreateQuery.cpp:383: DB::InterpreterCreateQuery::createDatabase(DB::ASTCreateQuery&) @ 0x00000000148e8e14 8. /build/src/Interpreters/InterpreterCreateQuery.cpp:2351: DB::InterpreterCreateQuery::execute() @ 0x0000000014905a3a 9. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88dc9 10. /build/src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x0000000014c8ca7b 11. /build/src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000001686da12 12. /build/src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x0000000016870807 13. /build/src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x0000000016907e99 14. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 15. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 16. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 17. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 18. ? @ 0x00007fbc6213eac3 19. ? @ 0x00007fbc621d0850 (version 25.3.6.10636.altinitytest (altinity build)) 2025.07.28 11:56:47.896944 [ 17306 ] {0a787c13-a70a-4be7-8c1c-df562c7c1e62} executeQuery: Code: 253. DB::Exception: Replica r1 of shard s1 of replicated database at /test/db/test_14 already exists. Replica host ID: '146b4357c08d:9000:2e9f5a5a-d01a-404b-9f39-a9efc39ca82f', current host ID: '146b4357c08d:9000:acef6827-aeda-46cc-bb5f-269d9acfbec7'. (REPLICA_ALREADY_EXISTS) (version 25.3.6.10636.altinitytest (altinity build)) (from [::1]:36392) (comment: 03141_fetches_errors_stress.sql) (in query: CREATE DATABASE IF NOT EXISTS test_lzju37at ENGINE=Replicated('/test/db/test_14', 's1', 'r1') ), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.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&) @ 0x0000000013db5399 4. /build/src/Databases/DatabaseReplicated.cpp:494: DB::DatabaseReplicated::tryConnectToZooKeeperAndInitDatabase(DB::LoadingStrictnessLevel) @ 0x0000000013d91155 5. /build/src/Databases/DatabaseReplicated.cpp:735: DB::DatabaseReplicated::beforeLoadingMetadata(std::shared_ptr, DB::LoadingStrictnessLevel) @ 0x0000000013d954d4 6. /build/src/Databases/TablesLoader.cpp:57: DB::TablesLoader::loadTablesAsync(std::unordered_set, std::hash>, std::equal_to>, std::allocator>>) @ 0x000000001490e734 7. /build/src/Interpreters/InterpreterCreateQuery.cpp:383: DB::InterpreterCreateQuery::createDatabase(DB::ASTCreateQuery&) @ 0x00000000148e8e14 8. /build/src/Interpreters/InterpreterCreateQuery.cpp:2351: DB::InterpreterCreateQuery::execute() @ 0x0000000014905a3a 9. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88dc9 10. /build/src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x0000000014c8ca7b 11. /build/src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000001686da12 12. /build/src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x0000000016870807 13. /build/src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x0000000016907e99 14. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 15. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 16. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 17. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 18. ? @ 0x00007fbc6213eac3 19. ? @ 0x00007fbc621d0850 2025.07.28 11:56:47.898305 [ 17306 ] {0a787c13-a70a-4be7-8c1c-df562c7c1e62} DynamicQueryHandler: Code: 253. DB::Exception: Replica r1 of shard s1 of replicated database at /test/db/test_14 already exists. Replica host ID: '146b4357c08d:9000:2e9f5a5a-d01a-404b-9f39-a9efc39ca82f', current host ID: '146b4357c08d:9000:acef6827-aeda-46cc-bb5f-269d9acfbec7'. (REPLICA_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.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&) @ 0x0000000013db5399 4. /build/src/Databases/DatabaseReplicated.cpp:494: DB::DatabaseReplicated::tryConnectToZooKeeperAndInitDatabase(DB::LoadingStrictnessLevel) @ 0x0000000013d91155 5. /build/src/Databases/DatabaseReplicated.cpp:735: DB::DatabaseReplicated::beforeLoadingMetadata(std::shared_ptr, DB::LoadingStrictnessLevel) @ 0x0000000013d954d4 6. /build/src/Databases/TablesLoader.cpp:57: DB::TablesLoader::loadTablesAsync(std::unordered_set, std::hash>, std::equal_to>, std::allocator>>) @ 0x000000001490e734 7. /build/src/Interpreters/InterpreterCreateQuery.cpp:383: DB::InterpreterCreateQuery::createDatabase(DB::ASTCreateQuery&) @ 0x00000000148e8e14 8. /build/src/Interpreters/InterpreterCreateQuery.cpp:2351: DB::InterpreterCreateQuery::execute() @ 0x0000000014905a3a 9. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88dc9 10. /build/src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x0000000014c8ca7b 11. /build/src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000001686da12 12. /build/src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x0000000016870807 13. /build/src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x0000000016907e99 14. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 15. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 16. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 17. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 18. ? @ 0x00007fbc6213eac3 19. ? @ 0x00007fbc621d0850 (version 25.3.6.10636.altinitytest (altinity build)) 2025.07.28 11:56:48.035000 [ 17306 ] {8334059c-500f-471e-828b-de77fdf5122a} executeQuery: Code: 253. DB::Exception: Replica r1 of shard s1 of replicated database at /test/db/test_14 already exists. Replica host ID: '146b4357c08d:9000:2e9f5a5a-d01a-404b-9f39-a9efc39ca82f', current host ID: '146b4357c08d:9000:06f7abcd-bc7c-4ba5-9716-92472f379f44'. (REPLICA_ALREADY_EXISTS) (version 25.3.6.10636.altinitytest (altinity build)) (from [::1]:36422) (comment: 00056_view.sql) (in query: CREATE DATABASE IF NOT EXISTS test_wrc5o7qa ENGINE=Replicated('/test/db/test_14', 's1', 'r1') ), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.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&) @ 0x0000000013db5399 4. /build/src/Databases/DatabaseReplicated.cpp:494: DB::DatabaseReplicated::tryConnectToZooKeeperAndInitDatabase(DB::LoadingStrictnessLevel) @ 0x0000000013d91155 5. /build/src/Databases/DatabaseReplicated.cpp:735: DB::DatabaseReplicated::beforeLoadingMetadata(std::shared_ptr, DB::LoadingStrictnessLevel) @ 0x0000000013d954d4 6. /build/src/Databases/TablesLoader.cpp:57: DB::TablesLoader::loadTablesAsync(std::unordered_set, std::hash>, std::equal_to>, std::allocator>>) @ 0x000000001490e734 7. /build/src/Interpreters/InterpreterCreateQuery.cpp:383: DB::InterpreterCreateQuery::createDatabase(DB::ASTCreateQuery&) @ 0x00000000148e8e14 8. /build/src/Interpreters/InterpreterCreateQuery.cpp:2351: DB::InterpreterCreateQuery::execute() @ 0x0000000014905a3a 9. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88dc9 10. /build/src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x0000000014c8ca7b 11. /build/src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000001686da12 12. /build/src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x0000000016870807 13. /build/src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x0000000016907e99 14. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 15. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 16. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 17. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 18. ? @ 0x00007fbc6213eac3 19. ? @ 0x00007fbc621d0850 2025.07.28 11:56:48.036500 [ 17306 ] {8334059c-500f-471e-828b-de77fdf5122a} DynamicQueryHandler: Code: 253. DB::Exception: Replica r1 of shard s1 of replicated database at /test/db/test_14 already exists. Replica host ID: '146b4357c08d:9000:2e9f5a5a-d01a-404b-9f39-a9efc39ca82f', current host ID: '146b4357c08d:9000:06f7abcd-bc7c-4ba5-9716-92472f379f44'. (REPLICA_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.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&) @ 0x0000000013db5399 4. /build/src/Databases/DatabaseReplicated.cpp:494: DB::DatabaseReplicated::tryConnectToZooKeeperAndInitDatabase(DB::LoadingStrictnessLevel) @ 0x0000000013d91155 5. /build/src/Databases/DatabaseReplicated.cpp:735: DB::DatabaseReplicated::beforeLoadingMetadata(std::shared_ptr, DB::LoadingStrictnessLevel) @ 0x0000000013d954d4 6. /build/src/Databases/TablesLoader.cpp:57: DB::TablesLoader::loadTablesAsync(std::unordered_set, std::hash>, std::equal_to>, std::allocator>>) @ 0x000000001490e734 7. /build/src/Interpreters/InterpreterCreateQuery.cpp:383: DB::InterpreterCreateQuery::createDatabase(DB::ASTCreateQuery&) @ 0x00000000148e8e14 8. /build/src/Interpreters/InterpreterCreateQuery.cpp:2351: DB::InterpreterCreateQuery::execute() @ 0x0000000014905a3a 9. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88dc9 10. /build/src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x0000000014c8ca7b 11. /build/src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000001686da12 12. /build/src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x0000000016870807 13. /build/src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x0000000016907e99 14. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 15. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 16. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 17. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 18. ? @ 0x00007fbc6213eac3 19. ? @ 0x00007fbc621d0850 (version 25.3.6.10636.altinitytest (altinity build)) 2025.07.28 11:56:48.108115 [ 17306 ] {92df18e7-f385-4259-b0ea-4b12e87875fd} executeQuery: Code: 253. DB::Exception: Replica r1 of shard s1 of replicated database at /test/db/test_14 already exists. Replica host ID: '146b4357c08d:9000:2e9f5a5a-d01a-404b-9f39-a9efc39ca82f', current host ID: '146b4357c08d:9000:e8c7b03c-a557-46f4-87b7-ac9d30e0cb3c'. (REPLICA_ALREADY_EXISTS) (version 25.3.6.10636.altinitytest (altinity build)) (from [::1]:36454) (comment: 00161_parallel_parsing_with_names.sh) (in query: CREATE DATABASE IF NOT EXISTS test_kwljr22e ENGINE=Replicated('/test/db/test_14', 's1', 'r1') ), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.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&) @ 0x0000000013db5399 4. /build/src/Databases/DatabaseReplicated.cpp:494: DB::DatabaseReplicated::tryConnectToZooKeeperAndInitDatabase(DB::LoadingStrictnessLevel) @ 0x0000000013d91155 5. /build/src/Databases/DatabaseReplicated.cpp:735: DB::DatabaseReplicated::beforeLoadingMetadata(std::shared_ptr, DB::LoadingStrictnessLevel) @ 0x0000000013d954d4 6. /build/src/Databases/TablesLoader.cpp:57: DB::TablesLoader::loadTablesAsync(std::unordered_set, std::hash>, std::equal_to>, std::allocator>>) @ 0x000000001490e734 7. /build/src/Interpreters/InterpreterCreateQuery.cpp:383: DB::InterpreterCreateQuery::createDatabase(DB::ASTCreateQuery&) @ 0x00000000148e8e14 8. /build/src/Interpreters/InterpreterCreateQuery.cpp:2351: DB::InterpreterCreateQuery::execute() @ 0x0000000014905a3a 9. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88dc9 10. /build/src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x0000000014c8ca7b 11. /build/src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000001686da12 12. /build/src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x0000000016870807 13. /build/src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x0000000016907e99 14. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 15. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 16. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 17. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 18. ? @ 0x00007fbc6213eac3 19. ? @ 0x00007fbc621d0850 2025.07.28 11:56:48.123261 [ 17306 ] {92df18e7-f385-4259-b0ea-4b12e87875fd} DynamicQueryHandler: Code: 253. DB::Exception: Replica r1 of shard s1 of replicated database at /test/db/test_14 already exists. Replica host ID: '146b4357c08d:9000:2e9f5a5a-d01a-404b-9f39-a9efc39ca82f', current host ID: '146b4357c08d:9000:e8c7b03c-a557-46f4-87b7-ac9d30e0cb3c'. (REPLICA_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.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&) @ 0x0000000013db5399 4. /build/src/Databases/DatabaseReplicated.cpp:494: DB::DatabaseReplicated::tryConnectToZooKeeperAndInitDatabase(DB::LoadingStrictnessLevel) @ 0x0000000013d91155 5. /build/src/Databases/DatabaseReplicated.cpp:735: DB::DatabaseReplicated::beforeLoadingMetadata(std::shared_ptr, DB::LoadingStrictnessLevel) @ 0x0000000013d954d4 6. /build/src/Databases/TablesLoader.cpp:57: DB::TablesLoader::loadTablesAsync(std::unordered_set, std::hash>, std::equal_to>, std::allocator>>) @ 0x000000001490e734 7. /build/src/Interpreters/InterpreterCreateQuery.cpp:383: DB::InterpreterCreateQuery::createDatabase(DB::ASTCreateQuery&) @ 0x00000000148e8e14 8. /build/src/Interpreters/InterpreterCreateQuery.cpp:2351: DB::InterpreterCreateQuery::execute() @ 0x0000000014905a3a 9. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88dc9 10. /build/src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x0000000014c8ca7b 11. /build/src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000001686da12 12. /build/src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x0000000016870807 13. /build/src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x0000000016907e99 14. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 15. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 16. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 17. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 18. ? @ 0x00007fbc6213eac3 19. ? @ 0x00007fbc621d0850 (version 25.3.6.10636.altinitytest (altinity build)) 2025.07.28 11:56:48.151719 [ 3974 ] {} test_13.rmt2 (7f9b740d-015c-470e-8cc6-8ba33be0dc63): auto DB::StorageReplicatedMergeTree::processQueueEntry(ReplicatedMergeTreeQueue::SelectedEntryPtr)::(anonymous class)::operator()(LogEntryPtr &) const: Code: 86. DB::HTTPException: Received error from remote server http://146b4357c08d:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Ftest%2F01165%2Ftest_13%2Frmt%2Freplicas%2F1&part=20250728_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.6.10636.altinitytest (altinity build)) '. (RECEIVED_ERROR_FROM_REMOTE_IO_SERVER), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.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 const&, int&&, String const&, unsigned long&&, String const&) @ 0x000000000feda8d9 4. /build/src/IO/HTTPCommon.cpp:104: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x000000000feda6e2 5. /build/src/IO/HTTPCommon.cpp:93: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x000000000feda537 6. /build/src/IO/ReadWriteBufferFromHTTP.cpp:277: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x000000001184a4c4 7. /build/src/IO/ReadWriteBufferFromHTTP.cpp:285: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x000000001184a615 8. /build/src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x000000001184ae59 9. /build/src/IO/ReadWriteBufferFromHTTP.cpp:472: void std::__function::__policy_invoker::__call_impl[abi:se190107]>(std::__function::__policy_storage const*) @ 0x000000001184cedd 10. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001184858b 11. /build/src/IO/ReadWriteBufferFromHTTP.cpp:465: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x000000001184bf0b 12. /build/src/IO/ReadBuffer.h:60: DB::ReadBuffer::next() @ 0x000000000a148c7b 13. /build/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) @ 0x0000000011849fb2 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]>&)>&, 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&) @ 0x0000000011841980 15. /build/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) @ 0x000000001621208e 16. /build/src/Storages/StorageReplicatedMergeTree.cpp:5228: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl[abi:se190107] const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000015f9a5fe 17. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000015ed8bfd 18. /build/src/Storages/StorageReplicatedMergeTree.cpp:2514: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x0000000015ec9aab 19. /build/src/Storages/StorageReplicatedMergeTree.cpp:2349: DB::StorageReplicatedMergeTree::executeLogEntry(DB::ReplicatedMergeTreeLogEntry&) @ 0x0000000015eba91b 20. /build/src/Storages/StorageReplicatedMergeTree.cpp:3876: bool std::__function::__policy_invoker&)>::__call_impl[abi:se190107])::$_1, bool (std::shared_ptr&)>>(std::__function::__policy_storage const*, std::shared_ptr&) @ 0x0000000015f9837e 21. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000165d6fc3 22. /build/src/Storages/StorageReplicatedMergeTree.cpp:3872: DB::StorageReplicatedMergeTree::processQueueEntry(std::shared_ptr) @ 0x0000000015efc18a 23. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001624c1b2 24. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000162f9c70 25. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x00000000162fa55a 26. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc6653 27. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000000fccc4c3 28. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc3d92 29. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fcca080 30. ? @ 0x00007fbc6213eac3 31. ? @ 0x00007fbc621d0850 (version 25.3.6.10636.altinitytest (altinity build)) 2025.07.28 11:56:48.241315 [ 4963 ] {46c621ad-c811-4900-b5ee-6a3836352c34} executeQuery: Code: 253. DB::Exception: Replica r1 of shard s1 of replicated database at /test/db/test_14 already exists. Replica host ID: '146b4357c08d:9000:2e9f5a5a-d01a-404b-9f39-a9efc39ca82f', current host ID: '146b4357c08d:9000:ded9e3ab-7e6c-42ae-8c3c-19cafe3795b6'. (REPLICA_ALREADY_EXISTS) (version 25.3.6.10636.altinitytest (altinity build)) (from [::1]:36478) (comment: 00076_system_columns_bytes.sql) (in query: CREATE DATABASE IF NOT EXISTS test_q5psmnbd ENGINE=Replicated('/test/db/test_14', 's1', 'r1') ), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.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&) @ 0x0000000013db5399 4. /build/src/Databases/DatabaseReplicated.cpp:494: DB::DatabaseReplicated::tryConnectToZooKeeperAndInitDatabase(DB::LoadingStrictnessLevel) @ 0x0000000013d91155 5. /build/src/Databases/DatabaseReplicated.cpp:735: DB::DatabaseReplicated::beforeLoadingMetadata(std::shared_ptr, DB::LoadingStrictnessLevel) @ 0x0000000013d954d4 6. /build/src/Databases/TablesLoader.cpp:57: DB::TablesLoader::loadTablesAsync(std::unordered_set, std::hash>, std::equal_to>, std::allocator>>) @ 0x000000001490e734 7. /build/src/Interpreters/InterpreterCreateQuery.cpp:383: DB::InterpreterCreateQuery::createDatabase(DB::ASTCreateQuery&) @ 0x00000000148e8e14 8. /build/src/Interpreters/InterpreterCreateQuery.cpp:2351: DB::InterpreterCreateQuery::execute() @ 0x0000000014905a3a 9. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88dc9 10. /build/src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x0000000014c8ca7b 11. /build/src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000001686da12 12. /build/src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x0000000016870807 13. /build/src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x0000000016907e99 14. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 15. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 16. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 17. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 18. ? @ 0x00007fbc6213eac3 19. ? @ 0x00007fbc621d0850 2025.07.28 11:56:48.244701 [ 4963 ] {46c621ad-c811-4900-b5ee-6a3836352c34} DynamicQueryHandler: Code: 253. DB::Exception: Replica r1 of shard s1 of replicated database at /test/db/test_14 already exists. Replica host ID: '146b4357c08d:9000:2e9f5a5a-d01a-404b-9f39-a9efc39ca82f', current host ID: '146b4357c08d:9000:ded9e3ab-7e6c-42ae-8c3c-19cafe3795b6'. (REPLICA_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.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&) @ 0x0000000013db5399 4. /build/src/Databases/DatabaseReplicated.cpp:494: DB::DatabaseReplicated::tryConnectToZooKeeperAndInitDatabase(DB::LoadingStrictnessLevel) @ 0x0000000013d91155 5. /build/src/Databases/DatabaseReplicated.cpp:735: DB::DatabaseReplicated::beforeLoadingMetadata(std::shared_ptr, DB::LoadingStrictnessLevel) @ 0x0000000013d954d4 6. /build/src/Databases/TablesLoader.cpp:57: DB::TablesLoader::loadTablesAsync(std::unordered_set, std::hash>, std::equal_to>, std::allocator>>) @ 0x000000001490e734 7. /build/src/Interpreters/InterpreterCreateQuery.cpp:383: DB::InterpreterCreateQuery::createDatabase(DB::ASTCreateQuery&) @ 0x00000000148e8e14 8. /build/src/Interpreters/InterpreterCreateQuery.cpp:2351: DB::InterpreterCreateQuery::execute() @ 0x0000000014905a3a 9. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88dc9 10. /build/src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x0000000014c8ca7b 11. /build/src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000001686da12 12. /build/src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x0000000016870807 13. /build/src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x0000000016907e99 14. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 15. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 16. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 17. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 18. ? @ 0x00007fbc6213eac3 19. ? @ 0x00007fbc621d0850 (version 25.3.6.10636.altinitytest (altinity build)) 2025.07.28 11:56:48.328809 [ 3283 ] {bcd520e6-eebd-4e90-88fc-0d0466d9d1e0} executeQuery: Code: 253. DB::Exception: Replica r1 of shard s1 of replicated database at /test/db/test_14 already exists. Replica host ID: '146b4357c08d:9000:2e9f5a5a-d01a-404b-9f39-a9efc39ca82f', current host ID: '146b4357c08d:9000:a9dfc631-d8c7-4212-956a-6614d585d05e'. (REPLICA_ALREADY_EXISTS) (version 25.3.6.10636.altinitytest (altinity build)) (from [::1]:36490) (comment: 03277_prewarm_cache_2.sh) (in query: CREATE DATABASE IF NOT EXISTS test_yz6n7kn0 ENGINE=Replicated('/test/db/test_14', 's1', 'r1') ), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.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&) @ 0x0000000013db5399 4. /build/src/Databases/DatabaseReplicated.cpp:494: DB::DatabaseReplicated::tryConnectToZooKeeperAndInitDatabase(DB::LoadingStrictnessLevel) @ 0x0000000013d91155 5. /build/src/Databases/DatabaseReplicated.cpp:735: DB::DatabaseReplicated::beforeLoadingMetadata(std::shared_ptr, DB::LoadingStrictnessLevel) @ 0x0000000013d954d4 6. /build/src/Databases/TablesLoader.cpp:57: DB::TablesLoader::loadTablesAsync(std::unordered_set, std::hash>, std::equal_to>, std::allocator>>) @ 0x000000001490e734 7. /build/src/Interpreters/InterpreterCreateQuery.cpp:383: DB::InterpreterCreateQuery::createDatabase(DB::ASTCreateQuery&) @ 0x00000000148e8e14 8. /build/src/Interpreters/InterpreterCreateQuery.cpp:2351: DB::InterpreterCreateQuery::execute() @ 0x0000000014905a3a 9. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88dc9 10. /build/src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x0000000014c8ca7b 11. /build/src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000001686da12 12. /build/src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x0000000016870807 13. /build/src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x0000000016907e99 14. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 15. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 16. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 17. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 18. ? @ 0x00007fbc6213eac3 19. ? @ 0x00007fbc621d0850 2025.07.28 11:56:48.342077 [ 3283 ] {bcd520e6-eebd-4e90-88fc-0d0466d9d1e0} DynamicQueryHandler: Code: 253. DB::Exception: Replica r1 of shard s1 of replicated database at /test/db/test_14 already exists. Replica host ID: '146b4357c08d:9000:2e9f5a5a-d01a-404b-9f39-a9efc39ca82f', current host ID: '146b4357c08d:9000:a9dfc631-d8c7-4212-956a-6614d585d05e'. (REPLICA_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.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&) @ 0x0000000013db5399 4. /build/src/Databases/DatabaseReplicated.cpp:494: DB::DatabaseReplicated::tryConnectToZooKeeperAndInitDatabase(DB::LoadingStrictnessLevel) @ 0x0000000013d91155 5. /build/src/Databases/DatabaseReplicated.cpp:735: DB::DatabaseReplicated::beforeLoadingMetadata(std::shared_ptr, DB::LoadingStrictnessLevel) @ 0x0000000013d954d4 6. /build/src/Databases/TablesLoader.cpp:57: DB::TablesLoader::loadTablesAsync(std::unordered_set, std::hash>, std::equal_to>, std::allocator>>) @ 0x000000001490e734 7. /build/src/Interpreters/InterpreterCreateQuery.cpp:383: DB::InterpreterCreateQuery::createDatabase(DB::ASTCreateQuery&) @ 0x00000000148e8e14 8. /build/src/Interpreters/InterpreterCreateQuery.cpp:2351: DB::InterpreterCreateQuery::execute() @ 0x0000000014905a3a 9. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88dc9 10. /build/src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x0000000014c8ca7b 11. /build/src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000001686da12 12. /build/src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x0000000016870807 13. /build/src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x0000000016907e99 14. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 15. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 16. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 17. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 18. ? @ 0x00007fbc6213eac3 19. ? @ 0x00007fbc621d0850 (version 25.3.6.10636.altinitytest (altinity build)) 2025.07.28 11:56:48.764256 [ 3967 ] {} test_13.rmt2 (7f9b740d-015c-470e-8cc6-8ba33be0dc63): auto DB::StorageReplicatedMergeTree::processQueueEntry(ReplicatedMergeTreeQueue::SelectedEntryPtr)::(anonymous class)::operator()(LogEntryPtr &) const: Code: 86. DB::HTTPException: Received error from remote server http://146b4357c08d:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Ftest%2F01165%2Ftest_13%2Frmt%2Freplicas%2F1&part=20250728_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.6.10636.altinitytest (altinity build)) '. (RECEIVED_ERROR_FROM_REMOTE_IO_SERVER), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.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 const&, int&&, String const&, unsigned long&&, String const&) @ 0x000000000feda8d9 4. /build/src/IO/HTTPCommon.cpp:104: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x000000000feda6e2 5. /build/src/IO/HTTPCommon.cpp:93: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x000000000feda537 6. /build/src/IO/ReadWriteBufferFromHTTP.cpp:277: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x000000001184a4c4 7. /build/src/IO/ReadWriteBufferFromHTTP.cpp:285: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x000000001184a615 8. /build/src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x000000001184ae59 9. /build/src/IO/ReadWriteBufferFromHTTP.cpp:472: void std::__function::__policy_invoker::__call_impl[abi:se190107]>(std::__function::__policy_storage const*) @ 0x000000001184cedd 10. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001184858b 11. /build/src/IO/ReadWriteBufferFromHTTP.cpp:465: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x000000001184bf0b 12. /build/src/IO/ReadBuffer.h:60: DB::ReadBuffer::next() @ 0x000000000a148c7b 13. /build/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) @ 0x0000000011849fb2 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]>&)>&, 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&) @ 0x0000000011841980 15. /build/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) @ 0x000000001621208e 16. /build/src/Storages/StorageReplicatedMergeTree.cpp:5228: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl[abi:se190107] const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000015f9a5fe 17. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000015ed8bfd 18. /build/src/Storages/StorageReplicatedMergeTree.cpp:2514: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x0000000015ec9aab 19. /build/src/Storages/StorageReplicatedMergeTree.cpp:2349: DB::StorageReplicatedMergeTree::executeLogEntry(DB::ReplicatedMergeTreeLogEntry&) @ 0x0000000015eba91b 20. /build/src/Storages/StorageReplicatedMergeTree.cpp:3876: bool std::__function::__policy_invoker&)>::__call_impl[abi:se190107])::$_1, bool (std::shared_ptr&)>>(std::__function::__policy_storage const*, std::shared_ptr&) @ 0x0000000015f9837e 21. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000165d6fc3 22. /build/src/Storages/StorageReplicatedMergeTree.cpp:3872: DB::StorageReplicatedMergeTree::processQueueEntry(std::shared_ptr) @ 0x0000000015efc18a 23. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001624c1b2 24. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000162f9c70 25. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x00000000162fa55a 26. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc6653 27. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000000fccc4c3 28. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc3d92 29. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fcca080 30. ? @ 0x00007fbc6213eac3 31. ? @ 0x00007fbc621d0850 (version 25.3.6.10636.altinitytest (altinity build)) 2025.07.28 11:56:48.991217 [ 3968 ] {} test_13.rmt2 (7f9b740d-015c-470e-8cc6-8ba33be0dc63): auto DB::StorageReplicatedMergeTree::processQueueEntry(ReplicatedMergeTreeQueue::SelectedEntryPtr)::(anonymous class)::operator()(LogEntryPtr &) const: Code: 86. DB::HTTPException: Received error from remote server http://146b4357c08d:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Ftest%2F01165%2Ftest_13%2Frmt%2Freplicas%2F1&part=20250728_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.6.10636.altinitytest (altinity build)) '. (RECEIVED_ERROR_FROM_REMOTE_IO_SERVER), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.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 const&, int&&, String const&, unsigned long&&, String const&) @ 0x000000000feda8d9 4. /build/src/IO/HTTPCommon.cpp:104: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x000000000feda6e2 5. /build/src/IO/HTTPCommon.cpp:93: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x000000000feda537 6. /build/src/IO/ReadWriteBufferFromHTTP.cpp:277: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x000000001184a4c4 7. /build/src/IO/ReadWriteBufferFromHTTP.cpp:285: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x000000001184a615 8. /build/src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x000000001184ae59 9. /build/src/IO/ReadWriteBufferFromHTTP.cpp:472: void std::__function::__policy_invoker::__call_impl[abi:se190107]>(std::__function::__policy_storage const*) @ 0x000000001184cedd 10. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001184858b 11. /build/src/IO/ReadWriteBufferFromHTTP.cpp:465: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x000000001184bf0b 12. /build/src/IO/ReadBuffer.h:60: DB::ReadBuffer::next() @ 0x000000000a148c7b 13. /build/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) @ 0x0000000011849fb2 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]>&)>&, 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&) @ 0x0000000011841980 15. /build/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) @ 0x000000001621208e 16. /build/src/Storages/StorageReplicatedMergeTree.cpp:5228: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl[abi:se190107] const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000015f9a5fe 17. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000015ed8bfd 18. /build/src/Storages/StorageReplicatedMergeTree.cpp:2514: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x0000000015ec9aab 19. /build/src/Storages/StorageReplicatedMergeTree.cpp:2349: DB::StorageReplicatedMergeTree::executeLogEntry(DB::ReplicatedMergeTreeLogEntry&) @ 0x0000000015eba91b 20. /build/src/Storages/StorageReplicatedMergeTree.cpp:3876: bool std::__function::__policy_invoker&)>::__call_impl[abi:se190107])::$_1, bool (std::shared_ptr&)>>(std::__function::__policy_storage const*, std::shared_ptr&) @ 0x0000000015f9837e 21. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000165d6fc3 22. /build/src/Storages/StorageReplicatedMergeTree.cpp:3872: DB::StorageReplicatedMergeTree::processQueueEntry(std::shared_ptr) @ 0x0000000015efc18a 23. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001624c1b2 24. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000162f9c70 25. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x00000000162fa55a 26. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc6653 27. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000000fccc4c3 28. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc3d92 29. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fcca080 30. ? @ 0x00007fbc6213eac3 31. ? @ 0x00007fbc621d0850 (version 25.3.6.10636.altinitytest (altinity build)) 2025.07.28 11:56:49.274801 [ 3283 ] {470e5ee3-7244-4799-aa08-9067f5773cbe} executeQuery: Code: 701. DB::Exception: Reading in parallel from replicas is enabled but cluster to execute query is not provided. Please set 'cluster_for_parallel_replicas' setting. (CLUSTER_DOESNT_EXIST) (version 25.3.6.10636.altinitytest (altinity build)) (from [::ffff:127.0.0.1]:57002) (comment: 02947_parallel_replicas_remote.sql) (query 4, line 10) (in query: SELECT count() AS `count()`, sum(`__table1`.`id`) AS `sum(id)` FROM `test_4rdayz11`.`test` AS `__table1`), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000000a074fcb 4. /build/src/Interpreters/Context.cpp:6297: DB::Context::getClusterForParallelReplicas() const @ 0x0000000014451291 5. /build/src/Interpreters/ClusterProxy/executeQuery.cpp:823: DB::ClusterProxy::canUseParallelReplicasOnInitiator(std::shared_ptr const&) @ 0x00000000158b28c6 6. /build/src/Planner/PlannerJoinTree.cpp:1012: DB::(anonymous namespace)::buildQueryPlanForTableExpression(std::shared_ptr, std::shared_ptr const&, DB::SelectQueryInfo const&, DB::SelectQueryOptions const&, std::shared_ptr&, bool, bool) @ 0x0000000014997182 7. /build/src/Planner/PlannerJoinTree.cpp:2252: DB::buildJoinTreeQueryPlan(std::shared_ptr const&, DB::SelectQueryInfo const&, DB::SelectQueryOptions&, std::unordered_set, std::equal_to, std::allocator> const&, std::shared_ptr&) @ 0x000000001498e109 8. /build/src/Planner/Planner.cpp:1553: DB::Planner::buildPlanForQueryNode() @ 0x0000000014979dae 9. /build/src/Planner/Planner.cpp:1308: DB::Planner::buildQueryPlanIfNeeded() @ 0x000000001497685c 10. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:255: DB::InterpreterSelectQueryAnalyzer::getQueryPlan() @ 0x000000001497476d 11. /build/src/Interpreters/executeQuery.cpp:1405: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88806 12. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 13. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 14. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 15. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 16. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 17. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 18. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 19. ? @ 0x00007fbc6213eac3 20. ? @ 0x00007fbc621d0850 2025.07.28 11:56:49.279537 [ 3283 ] {} TCPHandler: Code: 701. DB::Exception: Reading in parallel from replicas is enabled but cluster to execute query is not provided. Please set 'cluster_for_parallel_replicas' setting. (CLUSTER_DOESNT_EXIST), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000000a074fcb 4. /build/src/Interpreters/Context.cpp:6297: DB::Context::getClusterForParallelReplicas() const @ 0x0000000014451291 5. /build/src/Interpreters/ClusterProxy/executeQuery.cpp:823: DB::ClusterProxy::canUseParallelReplicasOnInitiator(std::shared_ptr const&) @ 0x00000000158b28c6 6. /build/src/Planner/PlannerJoinTree.cpp:1012: DB::(anonymous namespace)::buildQueryPlanForTableExpression(std::shared_ptr, std::shared_ptr const&, DB::SelectQueryInfo const&, DB::SelectQueryOptions const&, std::shared_ptr&, bool, bool) @ 0x0000000014997182 7. /build/src/Planner/PlannerJoinTree.cpp:2252: DB::buildJoinTreeQueryPlan(std::shared_ptr const&, DB::SelectQueryInfo const&, DB::SelectQueryOptions&, std::unordered_set, std::equal_to, std::allocator> const&, std::shared_ptr&) @ 0x000000001498e109 8. /build/src/Planner/Planner.cpp:1553: DB::Planner::buildPlanForQueryNode() @ 0x0000000014979dae 9. /build/src/Planner/Planner.cpp:1308: DB::Planner::buildQueryPlanIfNeeded() @ 0x000000001497685c 10. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:255: DB::InterpreterSelectQueryAnalyzer::getQueryPlan() @ 0x000000001497476d 11. /build/src/Interpreters/executeQuery.cpp:1405: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88806 12. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 13. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 14. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 15. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 16. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 17. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 18. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 19. ? @ 0x00007fbc6213eac3 20. ? @ 0x00007fbc621d0850 2025.07.28 11:56:49.289950 [ 17371 ] {e9755dea-8d0b-4dd7-b9d1-58e93f3038d8} executeQuery: Code: 701. DB::Exception: Received from 127.0.0.2:9000. DB::Exception: Reading in parallel from replicas is enabled but cluster to execute query is not provided. Please set 'cluster_for_parallel_replicas' setting. Stack trace: 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000000a074fcb 4. /build/src/Interpreters/Context.cpp:6297: DB::Context::getClusterForParallelReplicas() const @ 0x0000000014451291 5. /build/src/Interpreters/ClusterProxy/executeQuery.cpp:823: DB::ClusterProxy::canUseParallelReplicasOnInitiator(std::shared_ptr const&) @ 0x00000000158b28c6 6. /build/src/Planner/PlannerJoinTree.cpp:1012: DB::(anonymous namespace)::buildQueryPlanForTableExpression(std::shared_ptr, std::shared_ptr const&, DB::SelectQueryInfo const&, DB::SelectQueryOptions const&, std::shared_ptr&, bool, bool) @ 0x0000000014997182 7. /build/src/Planner/PlannerJoinTree.cpp:2252: DB::buildJoinTreeQueryPlan(std::shared_ptr const&, DB::SelectQueryInfo const&, DB::SelectQueryOptions&, std::unordered_set, std::equal_to, std::allocator> const&, std::shared_ptr&) @ 0x000000001498e109 8. /build/src/Planner/Planner.cpp:1553: DB::Planner::buildPlanForQueryNode() @ 0x0000000014979dae 9. /build/src/Planner/Planner.cpp:1308: DB::Planner::buildQueryPlanIfNeeded() @ 0x000000001497685c 10. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:255: DB::InterpreterSelectQueryAnalyzer::getQueryPlan() @ 0x000000001497476d 11. /build/src/Interpreters/executeQuery.cpp:1405: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88806 12. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 13. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 14. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 15. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 16. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 17. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 18. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 19. ? @ 0x00007fbc6213eac3 20. ? @ 0x00007fbc621d0850 : While executing Remote. (CLUSTER_DOESNT_EXIST) (version 25.3.6.10636.altinitytest (altinity build)) (from [::1]:57920) (comment: 02947_parallel_replicas_remote.sql) (query 4, line 10) (in query: SELECT count(), sum(id) FROM remote('127.0.0.1|127.0.0.2|127.0.0.3|127.0.0.4', currentDatabase(), test) SETTINGS enable_parallel_replicas = 2, max_parallel_replicas = 4, prefer_localhost_replica = 0, parallel_replicas_for_non_replicated_merge_tree = 1;), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:111: DB::readException(DB::ReadBuffer&, String const&, bool) @ 0x000000000fc6e157 3. /build/src/Client/Connection.cpp:1445: DB::Connection::receiveException() const @ 0x00000000167d4127 4. /build/src/Client/Connection.cpp:1274: DB::Connection::receivePacket() @ 0x00000000167db312 5. /build/src/Client/PacketReceiver.cpp:66: DB::PacketReceiver::Task::run(std::function, std::function) @ 0x0000000016819393 6. /build/src/Common/AsyncTaskExecutor.cpp:89: DB::AsyncTaskExecutor::Routine::operator()(std::function) @ 0x0000000013bd1892 7. /build/src/Common/Fiber.h:76: boost::context::detail::fiber_record>::run(void*) @ 0x0000000013bd16fa 8. /build/contrib/boost/boost/context/fiber_fcontext.hpp:97: void boost::context::detail::fiber_entry>>(boost::context::detail::transfer_t) @ 0x0000000013bd1621 2025.07.28 11:56:49.296266 [ 17371 ] {} TCPHandler: Code: 701. DB::Exception: Received from 127.0.0.2:9000. DB::Exception: Reading in parallel from replicas is enabled but cluster to execute query is not provided. Please set 'cluster_for_parallel_replicas' setting. Stack trace: 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000000a074fcb 4. /build/src/Interpreters/Context.cpp:6297: DB::Context::getClusterForParallelReplicas() const @ 0x0000000014451291 5. /build/src/Interpreters/ClusterProxy/executeQuery.cpp:823: DB::ClusterProxy::canUseParallelReplicasOnInitiator(std::shared_ptr const&) @ 0x00000000158b28c6 6. /build/src/Planner/PlannerJoinTree.cpp:1012: DB::(anonymous namespace)::buildQueryPlanForTableExpression(std::shared_ptr, std::shared_ptr const&, DB::SelectQueryInfo const&, DB::SelectQueryOptions const&, std::shared_ptr&, bool, bool) @ 0x0000000014997182 7. /build/src/Planner/PlannerJoinTree.cpp:2252: DB::buildJoinTreeQueryPlan(std::shared_ptr const&, DB::SelectQueryInfo const&, DB::SelectQueryOptions&, std::unordered_set, std::equal_to, std::allocator> const&, std::shared_ptr&) @ 0x000000001498e109 8. /build/src/Planner/Planner.cpp:1553: DB::Planner::buildPlanForQueryNode() @ 0x0000000014979dae 9. /build/src/Planner/Planner.cpp:1308: DB::Planner::buildQueryPlanIfNeeded() @ 0x000000001497685c 10. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:255: DB::InterpreterSelectQueryAnalyzer::getQueryPlan() @ 0x000000001497476d 11. /build/src/Interpreters/executeQuery.cpp:1405: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88806 12. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 13. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 14. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 15. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 16. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 17. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 18. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 19. ? @ 0x00007fbc6213eac3 20. ? @ 0x00007fbc621d0850 : While executing Remote. (CLUSTER_DOESNT_EXIST), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:111: DB::readException(DB::ReadBuffer&, String const&, bool) @ 0x000000000fc6e157 3. /build/src/Client/Connection.cpp:1445: DB::Connection::receiveException() const @ 0x00000000167d4127 4. /build/src/Client/Connection.cpp:1274: DB::Connection::receivePacket() @ 0x00000000167db312 5. /build/src/Client/PacketReceiver.cpp:66: DB::PacketReceiver::Task::run(std::function, std::function) @ 0x0000000016819393 6. /build/src/Common/AsyncTaskExecutor.cpp:89: DB::AsyncTaskExecutor::Routine::operator()(std::function) @ 0x0000000013bd1892 7. /build/src/Common/Fiber.h:76: boost::context::detail::fiber_record>::run(void*) @ 0x0000000013bd16fa 8. /build/contrib/boost/boost/context/fiber_fcontext.hpp:97: void boost::context::detail::fiber_entry>>(boost::context::detail::transfer_t) @ 0x0000000013bd1621 Job's origin stack trace: 0. /build/src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000000fc33b84 1. /build/src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000000fcc2ea7 2. /build/src/Common/ThreadPool.cpp:401: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fcc7f1c 3. /build/src/Common/ThreadPool.cpp:494: ThreadPoolImpl>::scheduleOrThrowOnError(std::function, Priority) @ 0x000000000fcc7a0e 4. /build/src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::spawnThreadsImpl() @ 0x00000000169b2c0c 5. /build/src/Processors/Executors/PipelineExecutor.cpp:394: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x00000000169b0ba7 6. /build/src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x00000000169b03f4 7. /build/src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:se190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169bfeab 8. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc3d92 9. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fcca080 10. ? @ 0x00007fbc6213eac3 11. ? @ 0x00007fbc621d0850 Job's origin stack trace: 0. /build/src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000000fc33b84 1. /build/src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000000fcc2ea7 2. /build/src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fcc535c 3. /build/src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000000fcc584d 4. /build/src/Common/ThreadPool.h:279: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x00000000169bf193 5. /build/src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x00000000169bf518 6. /build/src/Server/TCPHandler.cpp:1237: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x00000000168f1525 7. /build/src/Server/TCPHandler.cpp:678: DB::TCPHandler::runImpl() @ 0x00000000168e68e5 8. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 9. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 10. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 11. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 12. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 13. ? @ 0x00007fbc6213eac3 14. ? @ 0x00007fbc621d0850 2025.07.28 11:56:49.902356 [ 3962 ] {} test_13.rmt2 (7f9b740d-015c-470e-8cc6-8ba33be0dc63): auto DB::StorageReplicatedMergeTree::processQueueEntry(ReplicatedMergeTreeQueue::SelectedEntryPtr)::(anonymous class)::operator()(LogEntryPtr &) const: Code: 86. DB::HTTPException: Received error from remote server http://146b4357c08d:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Ftest%2F01165%2Ftest_13%2Frmt%2Freplicas%2F1&part=20250728_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.6.10636.altinitytest (altinity build)) '. (RECEIVED_ERROR_FROM_REMOTE_IO_SERVER), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.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 const&, int&&, String const&, unsigned long&&, String const&) @ 0x000000000feda8d9 4. /build/src/IO/HTTPCommon.cpp:104: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x000000000feda6e2 5. /build/src/IO/HTTPCommon.cpp:93: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x000000000feda537 6. /build/src/IO/ReadWriteBufferFromHTTP.cpp:277: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x000000001184a4c4 7. /build/src/IO/ReadWriteBufferFromHTTP.cpp:285: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x000000001184a615 8. /build/src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x000000001184ae59 9. /build/src/IO/ReadWriteBufferFromHTTP.cpp:472: void std::__function::__policy_invoker::__call_impl[abi:se190107]>(std::__function::__policy_storage const*) @ 0x000000001184cedd 10. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001184858b 11. /build/src/IO/ReadWriteBufferFromHTTP.cpp:465: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x000000001184bf0b 12. /build/src/IO/ReadBuffer.h:60: DB::ReadBuffer::next() @ 0x000000000a148c7b 13. /build/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) @ 0x0000000011849fb2 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]>&)>&, 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&) @ 0x0000000011841980 15. /build/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) @ 0x000000001621208e 16. /build/src/Storages/StorageReplicatedMergeTree.cpp:5228: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl[abi:se190107] const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000015f9a5fe 17. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000015ed8bfd 18. /build/src/Storages/StorageReplicatedMergeTree.cpp:2514: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x0000000015ec9aab 19. /build/src/Storages/StorageReplicatedMergeTree.cpp:2349: DB::StorageReplicatedMergeTree::executeLogEntry(DB::ReplicatedMergeTreeLogEntry&) @ 0x0000000015eba91b 20. /build/src/Storages/StorageReplicatedMergeTree.cpp:3876: bool std::__function::__policy_invoker&)>::__call_impl[abi:se190107])::$_1, bool (std::shared_ptr&)>>(std::__function::__policy_storage const*, std::shared_ptr&) @ 0x0000000015f9837e 21. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000165d6fc3 22. /build/src/Storages/StorageReplicatedMergeTree.cpp:3872: DB::StorageReplicatedMergeTree::processQueueEntry(std::shared_ptr) @ 0x0000000015efc18a 23. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001624c1b2 24. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000162f9c70 25. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x00000000162fa55a 26. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc6653 27. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000000fccc4c3 28. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc3d92 29. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fcca080 30. ? @ 0x00007fbc6213eac3 31. ? @ 0x00007fbc621d0850 (version 25.3.6.10636.altinitytest (altinity build)) 2025.07.28 11:56:50.829195 [ 3972 ] {} test_13.rmt2 (7f9b740d-015c-470e-8cc6-8ba33be0dc63): auto DB::StorageReplicatedMergeTree::processQueueEntry(ReplicatedMergeTreeQueue::SelectedEntryPtr)::(anonymous class)::operator()(LogEntryPtr &) const: Code: 86. DB::HTTPException: Received error from remote server http://146b4357c08d:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Ftest%2F01165%2Ftest_13%2Frmt%2Freplicas%2F1&part=20250728_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.6.10636.altinitytest (altinity build)) '. (RECEIVED_ERROR_FROM_REMOTE_IO_SERVER), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.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 const&, int&&, String const&, unsigned long&&, String const&) @ 0x000000000feda8d9 4. /build/src/IO/HTTPCommon.cpp:104: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x000000000feda6e2 5. /build/src/IO/HTTPCommon.cpp:93: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x000000000feda537 6. /build/src/IO/ReadWriteBufferFromHTTP.cpp:277: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x000000001184a4c4 7. /build/src/IO/ReadWriteBufferFromHTTP.cpp:285: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x000000001184a615 8. /build/src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x000000001184ae59 9. /build/src/IO/ReadWriteBufferFromHTTP.cpp:472: void std::__function::__policy_invoker::__call_impl[abi:se190107]>(std::__function::__policy_storage const*) @ 0x000000001184cedd 10. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001184858b 11. /build/src/IO/ReadWriteBufferFromHTTP.cpp:465: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x000000001184bf0b 12. /build/src/IO/ReadBuffer.h:60: DB::ReadBuffer::next() @ 0x000000000a148c7b 13. /build/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) @ 0x0000000011849fb2 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]>&)>&, 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&) @ 0x0000000011841980 15. /build/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) @ 0x000000001621208e 16. /build/src/Storages/StorageReplicatedMergeTree.cpp:5228: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl[abi:se190107] const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000015f9a5fe 17. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000015ed8bfd 18. /build/src/Storages/StorageReplicatedMergeTree.cpp:2514: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x0000000015ec9aab 19. /build/src/Storages/StorageReplicatedMergeTree.cpp:2349: DB::StorageReplicatedMergeTree::executeLogEntry(DB::ReplicatedMergeTreeLogEntry&) @ 0x0000000015eba91b 20. /build/src/Storages/StorageReplicatedMergeTree.cpp:3876: bool std::__function::__policy_invoker&)>::__call_impl[abi:se190107])::$_1, bool (std::shared_ptr&)>>(std::__function::__policy_storage const*, std::shared_ptr&) @ 0x0000000015f9837e 21. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000165d6fc3 22. /build/src/Storages/StorageReplicatedMergeTree.cpp:3872: DB::StorageReplicatedMergeTree::processQueueEntry(std::shared_ptr) @ 0x0000000015efc18a 23. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001624c1b2 24. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000162f9c70 25. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x00000000162fa55a 26. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc6653 27. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000000fccc4c3 28. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc3d92 29. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fcca080 30. ? @ 0x00007fbc6213eac3 31. ? @ 0x00007fbc621d0850 (version 25.3.6.10636.altinitytest (altinity build)) 2025.07.28 11:56:50.878725 [ 4963 ] {} 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. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception>&, String>(int, FormatStringHelperImpl>&>::type, std::type_identity::type>, std::basic_string_view>&, String&&) @ 0x000000001385a5eb 4. /build/src/Access/SettingsConstraints.cpp:376: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000013859b18 5. /build/src/Access/SettingsConstraints.cpp:300: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000013858faf 6. /build/src/Access/SettingsConstraints.cpp:209: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000013859223 7. /build/src/Interpreters/Context.cpp:2690: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000014436134 8. /build/src/Interpreters/Context.cpp:2729: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x000000001443662b 9. /build/src/Server/HTTPHandler.cpp:457: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000001686d165 10. /build/src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x0000000016870807 11. /build/src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x0000000016907e99 12. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 13. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 14. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 15. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 16. ? @ 0x00007fbc6213eac3 17. ? @ 0x00007fbc621d0850 (version 25.3.6.10636.altinitytest (altinity build)) 2025.07.28 11:56:51.861782 [ 3960 ] {} test_13.rmt2 (7f9b740d-015c-470e-8cc6-8ba33be0dc63): auto DB::StorageReplicatedMergeTree::processQueueEntry(ReplicatedMergeTreeQueue::SelectedEntryPtr)::(anonymous class)::operator()(LogEntryPtr &) const: Code: 86. DB::HTTPException: Received error from remote server http://146b4357c08d:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Ftest%2F01165%2Ftest_13%2Frmt%2Freplicas%2F1&part=20250728_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.6.10636.altinitytest (altinity build)) '. (RECEIVED_ERROR_FROM_REMOTE_IO_SERVER), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.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 const&, int&&, String const&, unsigned long&&, String const&) @ 0x000000000feda8d9 4. /build/src/IO/HTTPCommon.cpp:104: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x000000000feda6e2 5. /build/src/IO/HTTPCommon.cpp:93: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x000000000feda537 6. /build/src/IO/ReadWriteBufferFromHTTP.cpp:277: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x000000001184a4c4 7. /build/src/IO/ReadWriteBufferFromHTTP.cpp:285: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x000000001184a615 8. /build/src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x000000001184ae59 9. /build/src/IO/ReadWriteBufferFromHTTP.cpp:472: void std::__function::__policy_invoker::__call_impl[abi:se190107]>(std::__function::__policy_storage const*) @ 0x000000001184cedd 10. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001184858b 11. /build/src/IO/ReadWriteBufferFromHTTP.cpp:465: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x000000001184bf0b 12. /build/src/IO/ReadBuffer.h:60: DB::ReadBuffer::next() @ 0x000000000a148c7b 13. /build/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) @ 0x0000000011849fb2 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]>&)>&, 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&) @ 0x0000000011841980 15. /build/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) @ 0x000000001621208e 16. /build/src/Storages/StorageReplicatedMergeTree.cpp:5228: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl[abi:se190107] const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000015f9a5fe 17. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000015ed8bfd 18. /build/src/Storages/StorageReplicatedMergeTree.cpp:2514: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x0000000015ec9aab 19. /build/src/Storages/StorageReplicatedMergeTree.cpp:2349: DB::StorageReplicatedMergeTree::executeLogEntry(DB::ReplicatedMergeTreeLogEntry&) @ 0x0000000015eba91b 20. /build/src/Storages/StorageReplicatedMergeTree.cpp:3876: bool std::__function::__policy_invoker&)>::__call_impl[abi:se190107])::$_1, bool (std::shared_ptr&)>>(std::__function::__policy_storage const*, std::shared_ptr&) @ 0x0000000015f9837e 21. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000165d6fc3 22. /build/src/Storages/StorageReplicatedMergeTree.cpp:3872: DB::StorageReplicatedMergeTree::processQueueEntry(std::shared_ptr) @ 0x0000000015efc18a 23. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001624c1b2 24. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000162f9c70 25. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x00000000162fa55a 26. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc6653 27. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000000fccc4c3 28. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc3d92 29. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fcca080 30. ? @ 0x00007fbc6213eac3 31. ? @ 0x00007fbc621d0850 (version 25.3.6.10636.altinitytest (altinity build)) 2025.07.28 11:56:52.012986 [ 3964 ] {} test_13.rmt2 (7f9b740d-015c-470e-8cc6-8ba33be0dc63): auto DB::StorageReplicatedMergeTree::processQueueEntry(ReplicatedMergeTreeQueue::SelectedEntryPtr)::(anonymous class)::operator()(LogEntryPtr &) const: Code: 86. DB::HTTPException: Received error from remote server http://146b4357c08d:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Ftest%2F01165%2Ftest_13%2Frmt%2Freplicas%2F1&part=20250728_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.6.10636.altinitytest (altinity build)) '. (RECEIVED_ERROR_FROM_REMOTE_IO_SERVER), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.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 const&, int&&, String const&, unsigned long&&, String const&) @ 0x000000000feda8d9 4. /build/src/IO/HTTPCommon.cpp:104: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x000000000feda6e2 5. /build/src/IO/HTTPCommon.cpp:93: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x000000000feda537 6. /build/src/IO/ReadWriteBufferFromHTTP.cpp:277: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x000000001184a4c4 7. /build/src/IO/ReadWriteBufferFromHTTP.cpp:285: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x000000001184a615 8. /build/src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x000000001184ae59 9. /build/src/IO/ReadWriteBufferFromHTTP.cpp:472: void std::__function::__policy_invoker::__call_impl[abi:se190107]>(std::__function::__policy_storage const*) @ 0x000000001184cedd 10. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001184858b 11. /build/src/IO/ReadWriteBufferFromHTTP.cpp:465: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x000000001184bf0b 12. /build/src/IO/ReadBuffer.h:60: DB::ReadBuffer::next() @ 0x000000000a148c7b 13. /build/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) @ 0x0000000011849fb2 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]>&)>&, 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&) @ 0x0000000011841980 15. /build/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) @ 0x000000001621208e 16. /build/src/Storages/StorageReplicatedMergeTree.cpp:5228: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl[abi:se190107] const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000015f9a5fe 17. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000015ed8bfd 18. /build/src/Storages/StorageReplicatedMergeTree.cpp:2514: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x0000000015ec9aab 19. /build/src/Storages/StorageReplicatedMergeTree.cpp:2349: DB::StorageReplicatedMergeTree::executeLogEntry(DB::ReplicatedMergeTreeLogEntry&) @ 0x0000000015eba91b 20. /build/src/Storages/StorageReplicatedMergeTree.cpp:3876: bool std::__function::__policy_invoker&)>::__call_impl[abi:se190107])::$_1, bool (std::shared_ptr&)>>(std::__function::__policy_storage const*, std::shared_ptr&) @ 0x0000000015f9837e 21. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000165d6fc3 22. /build/src/Storages/StorageReplicatedMergeTree.cpp:3872: DB::StorageReplicatedMergeTree::processQueueEntry(std::shared_ptr) @ 0x0000000015efc18a 23. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001624c1b2 24. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000162f9c70 25. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x00000000162fa55a 26. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc6653 27. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000000fccc4c3 28. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc3d92 29. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fcca080 30. ? @ 0x00007fbc6213eac3 31. ? @ 0x00007fbc621d0850 (version 25.3.6.10636.altinitytest (altinity build)) 2025.07.28 11:56:52.284878 [ 3977 ] {} test_13.rmt2 (7f9b740d-015c-470e-8cc6-8ba33be0dc63): auto DB::StorageReplicatedMergeTree::processQueueEntry(ReplicatedMergeTreeQueue::SelectedEntryPtr)::(anonymous class)::operator()(LogEntryPtr &) const: Code: 86. DB::HTTPException: Received error from remote server http://146b4357c08d:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Ftest%2F01165%2Ftest_13%2Frmt%2Freplicas%2F1&part=20250728_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.6.10636.altinitytest (altinity build)) '. (RECEIVED_ERROR_FROM_REMOTE_IO_SERVER), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.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 const&, int&&, String const&, unsigned long&&, String const&) @ 0x000000000feda8d9 4. /build/src/IO/HTTPCommon.cpp:104: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x000000000feda6e2 5. /build/src/IO/HTTPCommon.cpp:93: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x000000000feda537 6. /build/src/IO/ReadWriteBufferFromHTTP.cpp:277: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x000000001184a4c4 7. /build/src/IO/ReadWriteBufferFromHTTP.cpp:285: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x000000001184a615 8. /build/src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x000000001184ae59 9. /build/src/IO/ReadWriteBufferFromHTTP.cpp:472: void std::__function::__policy_invoker::__call_impl[abi:se190107]>(std::__function::__policy_storage const*) @ 0x000000001184cedd 10. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001184858b 11. /build/src/IO/ReadWriteBufferFromHTTP.cpp:465: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x000000001184bf0b 12. /build/src/IO/ReadBuffer.h:60: DB::ReadBuffer::next() @ 0x000000000a148c7b 13. /build/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) @ 0x0000000011849fb2 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]>&)>&, 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&) @ 0x0000000011841980 15. /build/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) @ 0x000000001621208e 16. /build/src/Storages/StorageReplicatedMergeTree.cpp:5228: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl[abi:se190107] const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000015f9a5fe 17. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000015ed8bfd 18. /build/src/Storages/StorageReplicatedMergeTree.cpp:2514: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x0000000015ec9aab 19. /build/src/Storages/StorageReplicatedMergeTree.cpp:2349: DB::StorageReplicatedMergeTree::executeLogEntry(DB::ReplicatedMergeTreeLogEntry&) @ 0x0000000015eba91b 20. /build/src/Storages/StorageReplicatedMergeTree.cpp:3876: bool std::__function::__policy_invoker&)>::__call_impl[abi:se190107])::$_1, bool (std::shared_ptr&)>>(std::__function::__policy_storage const*, std::shared_ptr&) @ 0x0000000015f9837e 21. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000165d6fc3 22. /build/src/Storages/StorageReplicatedMergeTree.cpp:3872: DB::StorageReplicatedMergeTree::processQueueEntry(std::shared_ptr) @ 0x0000000015efc18a 23. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001624c1b2 24. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000162f9c70 25. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x00000000162fa55a 26. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc6653 27. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000000fccc4c3 28. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc3d92 29. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fcca080 30. ? @ 0x00007fbc6213eac3 31. ? @ 0x00007fbc621d0850 (version 25.3.6.10636.altinitytest (altinity build)) 2025.07.28 11:56:52.387227 [ 4963 ] {981ce4ab-ba48-48dc-8f69-8294e10c2dde} executeQuery: Code: 452. DB::Exception: Setting allow_experimental_object_type should not be changed. (SETTING_CONSTRAINT_VIOLATION) (version 25.3.6.10636.altinitytest (altinity build)) (from [::1]:50612) (comment: 02789_object_type_invalid_num_of_rows.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. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x000000000c25bc4b 4. /build/src/Access/SettingsConstraints.cpp:343: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000138596e3 5. /build/src/Access/SettingsConstraints.cpp:300: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000013858faf 6. /build/src/Access/SettingsConstraints.cpp:194: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges const&, DB::SettingSource) const @ 0x00000000138591b3 7. /build/src/Interpreters/Context.cpp:2722: DB::Context::checkSettingsConstraints(DB::SettingsChanges const&, DB::SettingSource) @ 0x0000000014436509 8. /build/src/Interpreters/InterpreterSetQuery.cpp:28: DB::InterpreterSetQuery::execute() @ 0x00000000149e240a 9. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88dc9 10. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 11. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 12. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 13. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 14. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 16. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 17. ? @ 0x00007fbc6213eac3 18. ? @ 0x00007fbc621d0850 2025.07.28 11:56:52.395521 [ 4963 ] {} 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. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x000000000c25bc4b 4. /build/src/Access/SettingsConstraints.cpp:343: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000138596e3 5. /build/src/Access/SettingsConstraints.cpp:300: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000013858faf 6. /build/src/Access/SettingsConstraints.cpp:194: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges const&, DB::SettingSource) const @ 0x00000000138591b3 7. /build/src/Interpreters/Context.cpp:2722: DB::Context::checkSettingsConstraints(DB::SettingsChanges const&, DB::SettingSource) @ 0x0000000014436509 8. /build/src/Interpreters/InterpreterSetQuery.cpp:28: DB::InterpreterSetQuery::execute() @ 0x00000000149e240a 9. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88dc9 10. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 11. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 12. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 13. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 14. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 16. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 17. ? @ 0x00007fbc6213eac3 18. ? @ 0x00007fbc621d0850 2025.07.28 11:56:52.894405 [ 3965 ] {} test_13.rmt2 (7f9b740d-015c-470e-8cc6-8ba33be0dc63): auto DB::StorageReplicatedMergeTree::processQueueEntry(ReplicatedMergeTreeQueue::SelectedEntryPtr)::(anonymous class)::operator()(LogEntryPtr &) const: Code: 86. DB::HTTPException: Received error from remote server http://146b4357c08d:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Ftest%2F01165%2Ftest_13%2Frmt%2Freplicas%2F1&part=20250728_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.6.10636.altinitytest (altinity build)) '. (RECEIVED_ERROR_FROM_REMOTE_IO_SERVER), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.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 const&, int&&, String const&, unsigned long&&, String const&) @ 0x000000000feda8d9 4. /build/src/IO/HTTPCommon.cpp:104: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x000000000feda6e2 5. /build/src/IO/HTTPCommon.cpp:93: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x000000000feda537 6. /build/src/IO/ReadWriteBufferFromHTTP.cpp:277: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x000000001184a4c4 7. /build/src/IO/ReadWriteBufferFromHTTP.cpp:285: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x000000001184a615 8. /build/src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x000000001184ae59 9. /build/src/IO/ReadWriteBufferFromHTTP.cpp:472: void std::__function::__policy_invoker::__call_impl[abi:se190107]>(std::__function::__policy_storage const*) @ 0x000000001184cedd 10. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001184858b 11. /build/src/IO/ReadWriteBufferFromHTTP.cpp:465: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x000000001184bf0b 12. /build/src/IO/ReadBuffer.h:60: DB::ReadBuffer::next() @ 0x000000000a148c7b 13. /build/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) @ 0x0000000011849fb2 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]>&)>&, 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&) @ 0x0000000011841980 15. /build/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) @ 0x000000001621208e 16. /build/src/Storages/StorageReplicatedMergeTree.cpp:5228: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl[abi:se190107] const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000015f9a5fe 17. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000015ed8bfd 18. /build/src/Storages/StorageReplicatedMergeTree.cpp:2514: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x0000000015ec9aab 19. /build/src/Storages/StorageReplicatedMergeTree.cpp:2349: DB::StorageReplicatedMergeTree::executeLogEntry(DB::ReplicatedMergeTreeLogEntry&) @ 0x0000000015eba91b 20. /build/src/Storages/StorageReplicatedMergeTree.cpp:3876: bool std::__function::__policy_invoker&)>::__call_impl[abi:se190107])::$_1, bool (std::shared_ptr&)>>(std::__function::__policy_storage const*, std::shared_ptr&) @ 0x0000000015f9837e 21. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000165d6fc3 22. /build/src/Storages/StorageReplicatedMergeTree.cpp:3872: DB::StorageReplicatedMergeTree::processQueueEntry(std::shared_ptr) @ 0x0000000015efc18a 23. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001624c1b2 24. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000162f9c70 25. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x00000000162fa55a 26. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc6653 27. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000000fccc4c3 28. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc3d92 29. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fcca080 30. ? @ 0x00007fbc6213eac3 31. ? @ 0x00007fbc621d0850 (version 25.3.6.10636.altinitytest (altinity build)) 2025.07.28 11:56:53.818108 [ 3961 ] {} test_13.rmt2 (7f9b740d-015c-470e-8cc6-8ba33be0dc63): auto DB::StorageReplicatedMergeTree::processQueueEntry(ReplicatedMergeTreeQueue::SelectedEntryPtr)::(anonymous class)::operator()(LogEntryPtr &) const: Code: 86. DB::HTTPException: Received error from remote server http://146b4357c08d:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Ftest%2F01165%2Ftest_13%2Frmt%2Freplicas%2F1&part=20250728_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.6.10636.altinitytest (altinity build)) '. (RECEIVED_ERROR_FROM_REMOTE_IO_SERVER), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.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 const&, int&&, String const&, unsigned long&&, String const&) @ 0x000000000feda8d9 4. /build/src/IO/HTTPCommon.cpp:104: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x000000000feda6e2 5. /build/src/IO/HTTPCommon.cpp:93: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x000000000feda537 6. /build/src/IO/ReadWriteBufferFromHTTP.cpp:277: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x000000001184a4c4 7. /build/src/IO/ReadWriteBufferFromHTTP.cpp:285: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x000000001184a615 8. /build/src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x000000001184ae59 9. /build/src/IO/ReadWriteBufferFromHTTP.cpp:472: void std::__function::__policy_invoker::__call_impl[abi:se190107]>(std::__function::__policy_storage const*) @ 0x000000001184cedd 10. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001184858b 11. /build/src/IO/ReadWriteBufferFromHTTP.cpp:465: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x000000001184bf0b 12. /build/src/IO/ReadBuffer.h:60: DB::ReadBuffer::next() @ 0x000000000a148c7b 13. /build/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) @ 0x0000000011849fb2 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]>&)>&, 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&) @ 0x0000000011841980 15. /build/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) @ 0x000000001621208e 16. /build/src/Storages/StorageReplicatedMergeTree.cpp:5228: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl[abi:se190107] const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000015f9a5fe 17. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000015ed8bfd 18. /build/src/Storages/StorageReplicatedMergeTree.cpp:2514: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x0000000015ec9aab 19. /build/src/Storages/StorageReplicatedMergeTree.cpp:2349: DB::StorageReplicatedMergeTree::executeLogEntry(DB::ReplicatedMergeTreeLogEntry&) @ 0x0000000015eba91b 20. /build/src/Storages/StorageReplicatedMergeTree.cpp:3876: bool std::__function::__policy_invoker&)>::__call_impl[abi:se190107])::$_1, bool (std::shared_ptr&)>>(std::__function::__policy_storage const*, std::shared_ptr&) @ 0x0000000015f9837e 21. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000165d6fc3 22. /build/src/Storages/StorageReplicatedMergeTree.cpp:3872: DB::StorageReplicatedMergeTree::processQueueEntry(std::shared_ptr) @ 0x0000000015efc18a 23. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001624c1b2 24. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000162f9c70 25. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x00000000162fa55a 26. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc6653 27. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000000fccc4c3 28. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc3d92 29. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fcca080 30. ? @ 0x00007fbc6213eac3 31. ? @ 0x00007fbc621d0850 (version 25.3.6.10636.altinitytest (altinity build)) 2025.07.28 11:56:54.291346 [ 3970 ] {} test_13.rmt2 (7f9b740d-015c-470e-8cc6-8ba33be0dc63): auto DB::StorageReplicatedMergeTree::processQueueEntry(ReplicatedMergeTreeQueue::SelectedEntryPtr)::(anonymous class)::operator()(LogEntryPtr &) const: Code: 86. DB::HTTPException: Received error from remote server http://146b4357c08d:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Ftest%2F01165%2Ftest_13%2Frmt%2Freplicas%2F1&part=20250728_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.6.10636.altinitytest (altinity build)) '. (RECEIVED_ERROR_FROM_REMOTE_IO_SERVER), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.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 const&, int&&, String const&, unsigned long&&, String const&) @ 0x000000000feda8d9 4. /build/src/IO/HTTPCommon.cpp:104: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x000000000feda6e2 5. /build/src/IO/HTTPCommon.cpp:93: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x000000000feda537 6. /build/src/IO/ReadWriteBufferFromHTTP.cpp:277: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x000000001184a4c4 7. /build/src/IO/ReadWriteBufferFromHTTP.cpp:285: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x000000001184a615 8. /build/src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x000000001184ae59 9. /build/src/IO/ReadWriteBufferFromHTTP.cpp:472: void std::__function::__policy_invoker::__call_impl[abi:se190107]>(std::__function::__policy_storage const*) @ 0x000000001184cedd 10. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001184858b 11. /build/src/IO/ReadWriteBufferFromHTTP.cpp:465: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x000000001184bf0b 12. /build/src/IO/ReadBuffer.h:60: DB::ReadBuffer::next() @ 0x000000000a148c7b 13. /build/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) @ 0x0000000011849fb2 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]>&)>&, 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&) @ 0x0000000011841980 15. /build/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) @ 0x000000001621208e 16. /build/src/Storages/StorageReplicatedMergeTree.cpp:5228: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl[abi:se190107] const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000015f9a5fe 17. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000015ed8bfd 18. /build/src/Storages/StorageReplicatedMergeTree.cpp:2514: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x0000000015ec9aab 19. /build/src/Storages/StorageReplicatedMergeTree.cpp:2349: DB::StorageReplicatedMergeTree::executeLogEntry(DB::ReplicatedMergeTreeLogEntry&) @ 0x0000000015eba91b 20. /build/src/Storages/StorageReplicatedMergeTree.cpp:3876: bool std::__function::__policy_invoker&)>::__call_impl[abi:se190107])::$_1, bool (std::shared_ptr&)>>(std::__function::__policy_storage const*, std::shared_ptr&) @ 0x0000000015f9837e 21. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000165d6fc3 22. /build/src/Storages/StorageReplicatedMergeTree.cpp:3872: DB::StorageReplicatedMergeTree::processQueueEntry(std::shared_ptr) @ 0x0000000015efc18a 23. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001624c1b2 24. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000162f9c70 25. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x00000000162fa55a 26. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc6653 27. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000000fccc4c3 28. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc3d92 29. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fcca080 30. ? @ 0x00007fbc6213eac3 31. ? @ 0x00007fbc621d0850 (version 25.3.6.10636.altinitytest (altinity build)) 2025.07.28 11:56:54.564290 [ 3960 ] {} test_13.rmt2 (7f9b740d-015c-470e-8cc6-8ba33be0dc63): auto DB::StorageReplicatedMergeTree::processQueueEntry(ReplicatedMergeTreeQueue::SelectedEntryPtr)::(anonymous class)::operator()(LogEntryPtr &) const: Code: 86. DB::HTTPException: Received error from remote server http://146b4357c08d:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Ftest%2F01165%2Ftest_13%2Frmt%2Freplicas%2F1&part=20250728_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.6.10636.altinitytest (altinity build)) '. (RECEIVED_ERROR_FROM_REMOTE_IO_SERVER), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.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 const&, int&&, String const&, unsigned long&&, String const&) @ 0x000000000feda8d9 4. /build/src/IO/HTTPCommon.cpp:104: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x000000000feda6e2 5. /build/src/IO/HTTPCommon.cpp:93: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x000000000feda537 6. /build/src/IO/ReadWriteBufferFromHTTP.cpp:277: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x000000001184a4c4 7. /build/src/IO/ReadWriteBufferFromHTTP.cpp:285: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x000000001184a615 8. /build/src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x000000001184ae59 9. /build/src/IO/ReadWriteBufferFromHTTP.cpp:472: void std::__function::__policy_invoker::__call_impl[abi:se190107]>(std::__function::__policy_storage const*) @ 0x000000001184cedd 10. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001184858b 11. /build/src/IO/ReadWriteBufferFromHTTP.cpp:465: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x000000001184bf0b 12. /build/src/IO/ReadBuffer.h:60: DB::ReadBuffer::next() @ 0x000000000a148c7b 13. /build/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) @ 0x0000000011849fb2 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]>&)>&, 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&) @ 0x0000000011841980 15. /build/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) @ 0x000000001621208e 16. /build/src/Storages/StorageReplicatedMergeTree.cpp:5228: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl[abi:se190107] const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000015f9a5fe 17. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000015ed8bfd 18. /build/src/Storages/StorageReplicatedMergeTree.cpp:2514: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x0000000015ec9aab 19. /build/src/Storages/StorageReplicatedMergeTree.cpp:2349: DB::StorageReplicatedMergeTree::executeLogEntry(DB::ReplicatedMergeTreeLogEntry&) @ 0x0000000015eba91b 20. /build/src/Storages/StorageReplicatedMergeTree.cpp:3876: bool std::__function::__policy_invoker&)>::__call_impl[abi:se190107])::$_1, bool (std::shared_ptr&)>>(std::__function::__policy_storage const*, std::shared_ptr&) @ 0x0000000015f9837e 21. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000165d6fc3 22. /build/src/Storages/StorageReplicatedMergeTree.cpp:3872: DB::StorageReplicatedMergeTree::processQueueEntry(std::shared_ptr) @ 0x0000000015efc18a 23. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001624c1b2 24. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000162f9c70 25. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x00000000162fa55a 26. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc6653 27. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000000fccc4c3 28. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc3d92 29. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fcca080 30. ? @ 0x00007fbc6213eac3 31. ? @ 0x00007fbc621d0850 (version 25.3.6.10636.altinitytest (altinity build)) 2025.07.28 11:56:54.804255 [ 3974 ] {} test_13.rmt2 (7f9b740d-015c-470e-8cc6-8ba33be0dc63): auto DB::StorageReplicatedMergeTree::processQueueEntry(ReplicatedMergeTreeQueue::SelectedEntryPtr)::(anonymous class)::operator()(LogEntryPtr &) const: Code: 86. DB::HTTPException: Received error from remote server http://146b4357c08d:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Ftest%2F01165%2Ftest_13%2Frmt%2Freplicas%2F1&part=20250728_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.6.10636.altinitytest (altinity build)) '. (RECEIVED_ERROR_FROM_REMOTE_IO_SERVER), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.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 const&, int&&, String const&, unsigned long&&, String const&) @ 0x000000000feda8d9 4. /build/src/IO/HTTPCommon.cpp:104: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x000000000feda6e2 5. /build/src/IO/HTTPCommon.cpp:93: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x000000000feda537 6. /build/src/IO/ReadWriteBufferFromHTTP.cpp:277: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x000000001184a4c4 7. /build/src/IO/ReadWriteBufferFromHTTP.cpp:285: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x000000001184a615 8. /build/src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x000000001184ae59 9. /build/src/IO/ReadWriteBufferFromHTTP.cpp:472: void std::__function::__policy_invoker::__call_impl[abi:se190107]>(std::__function::__policy_storage const*) @ 0x000000001184cedd 10. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001184858b 11. /build/src/IO/ReadWriteBufferFromHTTP.cpp:465: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x000000001184bf0b 12. /build/src/IO/ReadBuffer.h:60: DB::ReadBuffer::next() @ 0x000000000a148c7b 13. /build/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) @ 0x0000000011849fb2 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]>&)>&, 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&) @ 0x0000000011841980 15. /build/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) @ 0x000000001621208e 16. /build/src/Storages/StorageReplicatedMergeTree.cpp:5228: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl[abi:se190107] const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000015f9a5fe 17. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000015ed8bfd 18. /build/src/Storages/StorageReplicatedMergeTree.cpp:2514: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x0000000015ec9aab 19. /build/src/Storages/StorageReplicatedMergeTree.cpp:2349: DB::StorageReplicatedMergeTree::executeLogEntry(DB::ReplicatedMergeTreeLogEntry&) @ 0x0000000015eba91b 20. /build/src/Storages/StorageReplicatedMergeTree.cpp:3876: bool std::__function::__policy_invoker&)>::__call_impl[abi:se190107])::$_1, bool (std::shared_ptr&)>>(std::__function::__policy_storage const*, std::shared_ptr&) @ 0x0000000015f9837e 21. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000165d6fc3 22. /build/src/Storages/StorageReplicatedMergeTree.cpp:3872: DB::StorageReplicatedMergeTree::processQueueEntry(std::shared_ptr) @ 0x0000000015efc18a 23. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001624c1b2 24. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000162f9c70 25. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x00000000162fa55a 26. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc6653 27. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000000fccc4c3 28. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc3d92 29. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fcca080 30. ? @ 0x00007fbc6213eac3 31. ? @ 0x00007fbc621d0850 (version 25.3.6.10636.altinitytest (altinity build)) 2025.07.28 11:56:55.902644 [ 3967 ] {} test_13.rmt2 (7f9b740d-015c-470e-8cc6-8ba33be0dc63): auto DB::StorageReplicatedMergeTree::processQueueEntry(ReplicatedMergeTreeQueue::SelectedEntryPtr)::(anonymous class)::operator()(LogEntryPtr &) const: Code: 86. DB::HTTPException: Received error from remote server http://146b4357c08d:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Ftest%2F01165%2Ftest_13%2Frmt%2Freplicas%2F1&part=20250728_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.6.10636.altinitytest (altinity build)) '. (RECEIVED_ERROR_FROM_REMOTE_IO_SERVER), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.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 const&, int&&, String const&, unsigned long&&, String const&) @ 0x000000000feda8d9 4. /build/src/IO/HTTPCommon.cpp:104: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x000000000feda6e2 5. /build/src/IO/HTTPCommon.cpp:93: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x000000000feda537 6. /build/src/IO/ReadWriteBufferFromHTTP.cpp:277: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x000000001184a4c4 7. /build/src/IO/ReadWriteBufferFromHTTP.cpp:285: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x000000001184a615 8. /build/src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x000000001184ae59 9. /build/src/IO/ReadWriteBufferFromHTTP.cpp:472: void std::__function::__policy_invoker::__call_impl[abi:se190107]>(std::__function::__policy_storage const*) @ 0x000000001184cedd 10. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001184858b 11. /build/src/IO/ReadWriteBufferFromHTTP.cpp:465: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x000000001184bf0b 12. /build/src/IO/ReadBuffer.h:60: DB::ReadBuffer::next() @ 0x000000000a148c7b 13. /build/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) @ 0x0000000011849fb2 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]>&)>&, 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&) @ 0x0000000011841980 15. /build/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) @ 0x000000001621208e 16. /build/src/Storages/StorageReplicatedMergeTree.cpp:5228: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl[abi:se190107] const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000015f9a5fe 17. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000015ed8bfd 18. /build/src/Storages/StorageReplicatedMergeTree.cpp:2514: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x0000000015ec9aab 19. /build/src/Storages/StorageReplicatedMergeTree.cpp:2349: DB::StorageReplicatedMergeTree::executeLogEntry(DB::ReplicatedMergeTreeLogEntry&) @ 0x0000000015eba91b 20. /build/src/Storages/StorageReplicatedMergeTree.cpp:3876: bool std::__function::__policy_invoker&)>::__call_impl[abi:se190107])::$_1, bool (std::shared_ptr&)>>(std::__function::__policy_storage const*, std::shared_ptr&) @ 0x0000000015f9837e 21. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000165d6fc3 22. /build/src/Storages/StorageReplicatedMergeTree.cpp:3872: DB::StorageReplicatedMergeTree::processQueueEntry(std::shared_ptr) @ 0x0000000015efc18a 23. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001624c1b2 24. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000162f9c70 25. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x00000000162fa55a 26. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc6653 27. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000000fccc4c3 28. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc3d92 29. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fcca080 30. ? @ 0x00007fbc6213eac3 31. ? @ 0x00007fbc621d0850 (version 25.3.6.10636.altinitytest (altinity build)) 2025.07.28 11:56:56.424033 [ 3964 ] {} test_13.rmt2 (7f9b740d-015c-470e-8cc6-8ba33be0dc63): auto DB::StorageReplicatedMergeTree::processQueueEntry(ReplicatedMergeTreeQueue::SelectedEntryPtr)::(anonymous class)::operator()(LogEntryPtr &) const: Code: 86. DB::HTTPException: Received error from remote server http://146b4357c08d:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Ftest%2F01165%2Ftest_13%2Frmt%2Freplicas%2F1&part=20250728_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.6.10636.altinitytest (altinity build)) '. (RECEIVED_ERROR_FROM_REMOTE_IO_SERVER), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.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 const&, int&&, String const&, unsigned long&&, String const&) @ 0x000000000feda8d9 4. /build/src/IO/HTTPCommon.cpp:104: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x000000000feda6e2 5. /build/src/IO/HTTPCommon.cpp:93: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x000000000feda537 6. /build/src/IO/ReadWriteBufferFromHTTP.cpp:277: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x000000001184a4c4 7. /build/src/IO/ReadWriteBufferFromHTTP.cpp:285: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x000000001184a615 8. /build/src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x000000001184ae59 9. /build/src/IO/ReadWriteBufferFromHTTP.cpp:472: void std::__function::__policy_invoker::__call_impl[abi:se190107]>(std::__function::__policy_storage const*) @ 0x000000001184cedd 10. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001184858b 11. /build/src/IO/ReadWriteBufferFromHTTP.cpp:465: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x000000001184bf0b 12. /build/src/IO/ReadBuffer.h:60: DB::ReadBuffer::next() @ 0x000000000a148c7b 13. /build/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) @ 0x0000000011849fb2 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]>&)>&, 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&) @ 0x0000000011841980 15. /build/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) @ 0x000000001621208e 16. /build/src/Storages/StorageReplicatedMergeTree.cpp:5228: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl[abi:se190107] const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000015f9a5fe 17. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000015ed8bfd 18. /build/src/Storages/StorageReplicatedMergeTree.cpp:2514: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x0000000015ec9aab 19. /build/src/Storages/StorageReplicatedMergeTree.cpp:2349: DB::StorageReplicatedMergeTree::executeLogEntry(DB::ReplicatedMergeTreeLogEntry&) @ 0x0000000015eba91b 20. /build/src/Storages/StorageReplicatedMergeTree.cpp:3876: bool std::__function::__policy_invoker&)>::__call_impl[abi:se190107])::$_1, bool (std::shared_ptr&)>>(std::__function::__policy_storage const*, std::shared_ptr&) @ 0x0000000015f9837e 21. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000165d6fc3 22. /build/src/Storages/StorageReplicatedMergeTree.cpp:3872: DB::StorageReplicatedMergeTree::processQueueEntry(std::shared_ptr) @ 0x0000000015efc18a 23. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001624c1b2 24. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000162f9c70 25. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x00000000162fa55a 26. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc6653 27. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000000fccc4c3 28. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc3d92 29. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fcca080 30. ? @ 0x00007fbc6213eac3 31. ? @ 0x00007fbc621d0850 (version 25.3.6.10636.altinitytest (altinity build)) 2025.07.28 11:56:57.012412 [ 3968 ] {} test_13.rmt2 (7f9b740d-015c-470e-8cc6-8ba33be0dc63): auto DB::StorageReplicatedMergeTree::processQueueEntry(ReplicatedMergeTreeQueue::SelectedEntryPtr)::(anonymous class)::operator()(LogEntryPtr &) const: Code: 86. DB::HTTPException: Received error from remote server http://146b4357c08d:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Ftest%2F01165%2Ftest_13%2Frmt%2Freplicas%2F1&part=20250728_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.6.10636.altinitytest (altinity build)) '. (RECEIVED_ERROR_FROM_REMOTE_IO_SERVER), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.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 const&, int&&, String const&, unsigned long&&, String const&) @ 0x000000000feda8d9 4. /build/src/IO/HTTPCommon.cpp:104: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x000000000feda6e2 5. /build/src/IO/HTTPCommon.cpp:93: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x000000000feda537 6. /build/src/IO/ReadWriteBufferFromHTTP.cpp:277: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x000000001184a4c4 7. /build/src/IO/ReadWriteBufferFromHTTP.cpp:285: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x000000001184a615 8. /build/src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x000000001184ae59 9. /build/src/IO/ReadWriteBufferFromHTTP.cpp:472: void std::__function::__policy_invoker::__call_impl[abi:se190107]>(std::__function::__policy_storage const*) @ 0x000000001184cedd 10. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001184858b 11. /build/src/IO/ReadWriteBufferFromHTTP.cpp:465: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x000000001184bf0b 12. /build/src/IO/ReadBuffer.h:60: DB::ReadBuffer::next() @ 0x000000000a148c7b 13. /build/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) @ 0x0000000011849fb2 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]>&)>&, 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&) @ 0x0000000011841980 15. /build/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) @ 0x000000001621208e 16. /build/src/Storages/StorageReplicatedMergeTree.cpp:5228: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl[abi:se190107] const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000015f9a5fe 17. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000015ed8bfd 18. /build/src/Storages/StorageReplicatedMergeTree.cpp:2514: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x0000000015ec9aab 19. /build/src/Storages/StorageReplicatedMergeTree.cpp:2349: DB::StorageReplicatedMergeTree::executeLogEntry(DB::ReplicatedMergeTreeLogEntry&) @ 0x0000000015eba91b 20. /build/src/Storages/StorageReplicatedMergeTree.cpp:3876: bool std::__function::__policy_invoker&)>::__call_impl[abi:se190107])::$_1, bool (std::shared_ptr&)>>(std::__function::__policy_storage const*, std::shared_ptr&) @ 0x0000000015f9837e 21. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000165d6fc3 22. /build/src/Storages/StorageReplicatedMergeTree.cpp:3872: DB::StorageReplicatedMergeTree::processQueueEntry(std::shared_ptr) @ 0x0000000015efc18a 23. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001624c1b2 24. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000162f9c70 25. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x00000000162fa55a 26. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc6653 27. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000000fccc4c3 28. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc3d92 29. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fcca080 30. ? @ 0x00007fbc6213eac3 31. ? @ 0x00007fbc621d0850 (version 25.3.6.10636.altinitytest (altinity build)) 2025.07.28 11:56:58.057025 [ 3962 ] {} test_13.rmt2 (7f9b740d-015c-470e-8cc6-8ba33be0dc63): auto DB::StorageReplicatedMergeTree::processQueueEntry(ReplicatedMergeTreeQueue::SelectedEntryPtr)::(anonymous class)::operator()(LogEntryPtr &) const: Code: 86. DB::HTTPException: Received error from remote server http://146b4357c08d:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Ftest%2F01165%2Ftest_13%2Frmt%2Freplicas%2F1&part=20250728_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.6.10636.altinitytest (altinity build)) '. (RECEIVED_ERROR_FROM_REMOTE_IO_SERVER), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.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 const&, int&&, String const&, unsigned long&&, String const&) @ 0x000000000feda8d9 4. /build/src/IO/HTTPCommon.cpp:104: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x000000000feda6e2 5. /build/src/IO/HTTPCommon.cpp:93: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x000000000feda537 6. /build/src/IO/ReadWriteBufferFromHTTP.cpp:277: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x000000001184a4c4 7. /build/src/IO/ReadWriteBufferFromHTTP.cpp:285: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x000000001184a615 8. /build/src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x000000001184ae59 9. /build/src/IO/ReadWriteBufferFromHTTP.cpp:472: void std::__function::__policy_invoker::__call_impl[abi:se190107]>(std::__function::__policy_storage const*) @ 0x000000001184cedd 10. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001184858b 11. /build/src/IO/ReadWriteBufferFromHTTP.cpp:465: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x000000001184bf0b 12. /build/src/IO/ReadBuffer.h:60: DB::ReadBuffer::next() @ 0x000000000a148c7b 13. /build/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) @ 0x0000000011849fb2 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]>&)>&, 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&) @ 0x0000000011841980 15. /build/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) @ 0x000000001621208e 16. /build/src/Storages/StorageReplicatedMergeTree.cpp:5228: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl[abi:se190107] const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000015f9a5fe 17. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000015ed8bfd 18. /build/src/Storages/StorageReplicatedMergeTree.cpp:2514: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x0000000015ec9aab 19. /build/src/Storages/StorageReplicatedMergeTree.cpp:2349: DB::StorageReplicatedMergeTree::executeLogEntry(DB::ReplicatedMergeTreeLogEntry&) @ 0x0000000015eba91b 20. /build/src/Storages/StorageReplicatedMergeTree.cpp:3876: bool std::__function::__policy_invoker&)>::__call_impl[abi:se190107])::$_1, bool (std::shared_ptr&)>>(std::__function::__policy_storage const*, std::shared_ptr&) @ 0x0000000015f9837e 21. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000165d6fc3 22. /build/src/Storages/StorageReplicatedMergeTree.cpp:3872: DB::StorageReplicatedMergeTree::processQueueEntry(std::shared_ptr) @ 0x0000000015efc18a 23. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001624c1b2 24. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000162f9c70 25. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x00000000162fa55a 26. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc6653 27. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000000fccc4c3 28. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc3d92 29. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fcca080 30. ? @ 0x00007fbc6213eac3 31. ? @ 0x00007fbc621d0850 (version 25.3.6.10636.altinitytest (altinity build)) 2025.07.28 11:56:58.496264 [ 3970 ] {} test_13.rmt2 (7f9b740d-015c-470e-8cc6-8ba33be0dc63): auto DB::StorageReplicatedMergeTree::processQueueEntry(ReplicatedMergeTreeQueue::SelectedEntryPtr)::(anonymous class)::operator()(LogEntryPtr &) const: Code: 86. DB::HTTPException: Received error from remote server http://146b4357c08d:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Ftest%2F01165%2Ftest_13%2Frmt%2Freplicas%2F1&part=20250728_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.6.10636.altinitytest (altinity build)) '. (RECEIVED_ERROR_FROM_REMOTE_IO_SERVER), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.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 const&, int&&, String const&, unsigned long&&, String const&) @ 0x000000000feda8d9 4. /build/src/IO/HTTPCommon.cpp:104: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x000000000feda6e2 5. /build/src/IO/HTTPCommon.cpp:93: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x000000000feda537 6. /build/src/IO/ReadWriteBufferFromHTTP.cpp:277: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x000000001184a4c4 7. /build/src/IO/ReadWriteBufferFromHTTP.cpp:285: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x000000001184a615 8. /build/src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x000000001184ae59 9. /build/src/IO/ReadWriteBufferFromHTTP.cpp:472: void std::__function::__policy_invoker::__call_impl[abi:se190107]>(std::__function::__policy_storage const*) @ 0x000000001184cedd 10. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001184858b 11. /build/src/IO/ReadWriteBufferFromHTTP.cpp:465: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x000000001184bf0b 12. /build/src/IO/ReadBuffer.h:60: DB::ReadBuffer::next() @ 0x000000000a148c7b 13. /build/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) @ 0x0000000011849fb2 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]>&)>&, 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&) @ 0x0000000011841980 15. /build/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) @ 0x000000001621208e 16. /build/src/Storages/StorageReplicatedMergeTree.cpp:5228: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl[abi:se190107] const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000015f9a5fe 17. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000015ed8bfd 18. /build/src/Storages/StorageReplicatedMergeTree.cpp:2514: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x0000000015ec9aab 19. /build/src/Storages/StorageReplicatedMergeTree.cpp:2349: DB::StorageReplicatedMergeTree::executeLogEntry(DB::ReplicatedMergeTreeLogEntry&) @ 0x0000000015eba91b 20. /build/src/Storages/StorageReplicatedMergeTree.cpp:3876: bool std::__function::__policy_invoker&)>::__call_impl[abi:se190107])::$_1, bool (std::shared_ptr&)>>(std::__function::__policy_storage const*, std::shared_ptr&) @ 0x0000000015f9837e 21. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000165d6fc3 22. /build/src/Storages/StorageReplicatedMergeTree.cpp:3872: DB::StorageReplicatedMergeTree::processQueueEntry(std::shared_ptr) @ 0x0000000015efc18a 23. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001624c1b2 24. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000162f9c70 25. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x00000000162fa55a 26. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc6653 27. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000000fccc4c3 28. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc3d92 29. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fcca080 30. ? @ 0x00007fbc6213eac3 31. ? @ 0x00007fbc621d0850 (version 25.3.6.10636.altinitytest (altinity build)) 2025.07.28 11:56:59.004873 [ 3965 ] {} test_13.rmt2 (7f9b740d-015c-470e-8cc6-8ba33be0dc63): auto DB::StorageReplicatedMergeTree::processQueueEntry(ReplicatedMergeTreeQueue::SelectedEntryPtr)::(anonymous class)::operator()(LogEntryPtr &) const: Code: 86. DB::HTTPException: Received error from remote server http://146b4357c08d:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Ftest%2F01165%2Ftest_13%2Frmt%2Freplicas%2F1&part=20250728_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.6.10636.altinitytest (altinity build)) '. (RECEIVED_ERROR_FROM_REMOTE_IO_SERVER), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.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 const&, int&&, String const&, unsigned long&&, String const&) @ 0x000000000feda8d9 4. /build/src/IO/HTTPCommon.cpp:104: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x000000000feda6e2 5. /build/src/IO/HTTPCommon.cpp:93: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x000000000feda537 6. /build/src/IO/ReadWriteBufferFromHTTP.cpp:277: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x000000001184a4c4 7. /build/src/IO/ReadWriteBufferFromHTTP.cpp:285: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x000000001184a615 8. /build/src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x000000001184ae59 9. /build/src/IO/ReadWriteBufferFromHTTP.cpp:472: void std::__function::__policy_invoker::__call_impl[abi:se190107]>(std::__function::__policy_storage const*) @ 0x000000001184cedd 10. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001184858b 11. /build/src/IO/ReadWriteBufferFromHTTP.cpp:465: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x000000001184bf0b 12. /build/src/IO/ReadBuffer.h:60: DB::ReadBuffer::next() @ 0x000000000a148c7b 13. /build/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) @ 0x0000000011849fb2 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]>&)>&, 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&) @ 0x0000000011841980 15. /build/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) @ 0x000000001621208e 16. /build/src/Storages/StorageReplicatedMergeTree.cpp:5228: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl[abi:se190107] const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000015f9a5fe 17. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000015ed8bfd 18. /build/src/Storages/StorageReplicatedMergeTree.cpp:2514: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x0000000015ec9aab 19. /build/src/Storages/StorageReplicatedMergeTree.cpp:2349: DB::StorageReplicatedMergeTree::executeLogEntry(DB::ReplicatedMergeTreeLogEntry&) @ 0x0000000015eba91b 20. /build/src/Storages/StorageReplicatedMergeTree.cpp:3876: bool std::__function::__policy_invoker&)>::__call_impl[abi:se190107])::$_1, bool (std::shared_ptr&)>>(std::__function::__policy_storage const*, std::shared_ptr&) @ 0x0000000015f9837e 21. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000165d6fc3 22. /build/src/Storages/StorageReplicatedMergeTree.cpp:3872: DB::StorageReplicatedMergeTree::processQueueEntry(std::shared_ptr) @ 0x0000000015efc18a 23. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001624c1b2 24. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000162f9c70 25. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x00000000162fa55a 26. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc6653 27. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000000fccc4c3 28. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc3d92 29. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fcca080 30. ? @ 0x00007fbc6213eac3 31. ? @ 0x00007fbc621d0850 (version 25.3.6.10636.altinitytest (altinity build)) 2025.07.28 11:56:59.151701 [ 3977 ] {} test_13.rmt2 (7f9b740d-015c-470e-8cc6-8ba33be0dc63): auto DB::StorageReplicatedMergeTree::processQueueEntry(ReplicatedMergeTreeQueue::SelectedEntryPtr)::(anonymous class)::operator()(LogEntryPtr &) const: Code: 86. DB::HTTPException: Received error from remote server http://146b4357c08d:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Ftest%2F01165%2Ftest_13%2Frmt%2Freplicas%2F1&part=20250728_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.6.10636.altinitytest (altinity build)) '. (RECEIVED_ERROR_FROM_REMOTE_IO_SERVER), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.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 const&, int&&, String const&, unsigned long&&, String const&) @ 0x000000000feda8d9 4. /build/src/IO/HTTPCommon.cpp:104: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x000000000feda6e2 5. /build/src/IO/HTTPCommon.cpp:93: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x000000000feda537 6. /build/src/IO/ReadWriteBufferFromHTTP.cpp:277: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x000000001184a4c4 7. /build/src/IO/ReadWriteBufferFromHTTP.cpp:285: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x000000001184a615 8. /build/src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x000000001184ae59 9. /build/src/IO/ReadWriteBufferFromHTTP.cpp:472: void std::__function::__policy_invoker::__call_impl[abi:se190107]>(std::__function::__policy_storage const*) @ 0x000000001184cedd 10. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001184858b 11. /build/src/IO/ReadWriteBufferFromHTTP.cpp:465: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x000000001184bf0b 12. /build/src/IO/ReadBuffer.h:60: DB::ReadBuffer::next() @ 0x000000000a148c7b 13. /build/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) @ 0x0000000011849fb2 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]>&)>&, 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&) @ 0x0000000011841980 15. /build/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) @ 0x000000001621208e 16. /build/src/Storages/StorageReplicatedMergeTree.cpp:5228: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl[abi:se190107] const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000015f9a5fe 17. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000015ed8bfd 18. /build/src/Storages/StorageReplicatedMergeTree.cpp:2514: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x0000000015ec9aab 19. /build/src/Storages/StorageReplicatedMergeTree.cpp:2349: DB::StorageReplicatedMergeTree::executeLogEntry(DB::ReplicatedMergeTreeLogEntry&) @ 0x0000000015eba91b 20. /build/src/Storages/StorageReplicatedMergeTree.cpp:3876: bool std::__function::__policy_invoker&)>::__call_impl[abi:se190107])::$_1, bool (std::shared_ptr&)>>(std::__function::__policy_storage const*, std::shared_ptr&) @ 0x0000000015f9837e 21. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000165d6fc3 22. /build/src/Storages/StorageReplicatedMergeTree.cpp:3872: DB::StorageReplicatedMergeTree::processQueueEntry(std::shared_ptr) @ 0x0000000015efc18a 23. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001624c1b2 24. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000162f9c70 25. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x00000000162fa55a 26. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc6653 27. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000000fccc4c3 28. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc3d92 29. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fcca080 30. ? @ 0x00007fbc6213eac3 31. ? @ 0x00007fbc621d0850 (version 25.3.6.10636.altinitytest (altinity build)) 2025.07.28 11:56:59.741403 [ 4900 ] {} 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. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception>&, String>(int, FormatStringHelperImpl>&>::type, std::type_identity::type>, std::basic_string_view>&, String&&) @ 0x000000001385a5eb 4. /build/src/Access/SettingsConstraints.cpp:376: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000013859b18 5. /build/src/Access/SettingsConstraints.cpp:300: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000013858faf 6. /build/src/Access/SettingsConstraints.cpp:209: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000013859223 7. /build/src/Interpreters/Context.cpp:2690: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000014436134 8. /build/src/Interpreters/Context.cpp:2729: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x000000001443662b 9. /build/src/Server/HTTPHandler.cpp:457: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000001686d165 10. /build/src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x0000000016870807 11. /build/src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x0000000016907e99 12. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 13. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 14. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 15. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 16. ? @ 0x00007fbc6213eac3 17. ? @ 0x00007fbc621d0850 (version 25.3.6.10636.altinitytest (altinity build)) 2025.07.28 11:56:59.861853 [ 3969 ] {} test_13.rmt2 (7f9b740d-015c-470e-8cc6-8ba33be0dc63): auto DB::StorageReplicatedMergeTree::processQueueEntry(ReplicatedMergeTreeQueue::SelectedEntryPtr)::(anonymous class)::operator()(LogEntryPtr &) const: Code: 86. DB::HTTPException: Received error from remote server http://146b4357c08d:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Ftest%2F01165%2Ftest_13%2Frmt%2Freplicas%2F1&part=20250728_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.6.10636.altinitytest (altinity build)) '. (RECEIVED_ERROR_FROM_REMOTE_IO_SERVER), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.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 const&, int&&, String const&, unsigned long&&, String const&) @ 0x000000000feda8d9 4. /build/src/IO/HTTPCommon.cpp:104: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x000000000feda6e2 5. /build/src/IO/HTTPCommon.cpp:93: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x000000000feda537 6. /build/src/IO/ReadWriteBufferFromHTTP.cpp:277: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x000000001184a4c4 7. /build/src/IO/ReadWriteBufferFromHTTP.cpp:285: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x000000001184a615 8. /build/src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x000000001184ae59 9. /build/src/IO/ReadWriteBufferFromHTTP.cpp:472: void std::__function::__policy_invoker::__call_impl[abi:se190107]>(std::__function::__policy_storage const*) @ 0x000000001184cedd 10. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001184858b 11. /build/src/IO/ReadWriteBufferFromHTTP.cpp:465: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x000000001184bf0b 12. /build/src/IO/ReadBuffer.h:60: DB::ReadBuffer::next() @ 0x000000000a148c7b 13. /build/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) @ 0x0000000011849fb2 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]>&)>&, 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&) @ 0x0000000011841980 15. /build/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) @ 0x000000001621208e 16. /build/src/Storages/StorageReplicatedMergeTree.cpp:5228: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl[abi:se190107] const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000015f9a5fe 17. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000015ed8bfd 18. /build/src/Storages/StorageReplicatedMergeTree.cpp:2514: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x0000000015ec9aab 19. /build/src/Storages/StorageReplicatedMergeTree.cpp:2349: DB::StorageReplicatedMergeTree::executeLogEntry(DB::ReplicatedMergeTreeLogEntry&) @ 0x0000000015eba91b 20. /build/src/Storages/StorageReplicatedMergeTree.cpp:3876: bool std::__function::__policy_invoker&)>::__call_impl[abi:se190107])::$_1, bool (std::shared_ptr&)>>(std::__function::__policy_storage const*, std::shared_ptr&) @ 0x0000000015f9837e 21. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000165d6fc3 22. /build/src/Storages/StorageReplicatedMergeTree.cpp:3872: DB::StorageReplicatedMergeTree::processQueueEntry(std::shared_ptr) @ 0x0000000015efc18a 23. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001624c1b2 24. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000162f9c70 25. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x00000000162fa55a 26. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc6653 27. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000000fccc4c3 28. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc3d92 29. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fcca080 30. ? @ 0x00007fbc6213eac3 31. ? @ 0x00007fbc621d0850 (version 25.3.6.10636.altinitytest (altinity build)) 2025.07.28 11:57:00.003393 [ 3971 ] {} test_13.rmt2 (7f9b740d-015c-470e-8cc6-8ba33be0dc63): auto DB::StorageReplicatedMergeTree::processQueueEntry(ReplicatedMergeTreeQueue::SelectedEntryPtr)::(anonymous class)::operator()(LogEntryPtr &) const: Code: 86. DB::HTTPException: Received error from remote server http://146b4357c08d:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Ftest%2F01165%2Ftest_13%2Frmt%2Freplicas%2F1&part=20250728_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.6.10636.altinitytest (altinity build)) '. (RECEIVED_ERROR_FROM_REMOTE_IO_SERVER), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.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 const&, int&&, String const&, unsigned long&&, String const&) @ 0x000000000feda8d9 4. /build/src/IO/HTTPCommon.cpp:104: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x000000000feda6e2 5. /build/src/IO/HTTPCommon.cpp:93: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x000000000feda537 6. /build/src/IO/ReadWriteBufferFromHTTP.cpp:277: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x000000001184a4c4 7. /build/src/IO/ReadWriteBufferFromHTTP.cpp:285: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x000000001184a615 8. /build/src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x000000001184ae59 9. /build/src/IO/ReadWriteBufferFromHTTP.cpp:472: void std::__function::__policy_invoker::__call_impl[abi:se190107]>(std::__function::__policy_storage const*) @ 0x000000001184cedd 10. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001184858b 11. /build/src/IO/ReadWriteBufferFromHTTP.cpp:465: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x000000001184bf0b 12. /build/src/IO/ReadBuffer.h:60: DB::ReadBuffer::next() @ 0x000000000a148c7b 13. /build/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) @ 0x0000000011849fb2 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]>&)>&, 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&) @ 0x0000000011841980 15. /build/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) @ 0x000000001621208e 16. /build/src/Storages/StorageReplicatedMergeTree.cpp:5228: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl[abi:se190107] const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000015f9a5fe 17. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000015ed8bfd 18. /build/src/Storages/StorageReplicatedMergeTree.cpp:2514: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x0000000015ec9aab 19. /build/src/Storages/StorageReplicatedMergeTree.cpp:2349: DB::StorageReplicatedMergeTree::executeLogEntry(DB::ReplicatedMergeTreeLogEntry&) @ 0x0000000015eba91b 20. /build/src/Storages/StorageReplicatedMergeTree.cpp:3876: bool std::__function::__policy_invoker&)>::__call_impl[abi:se190107])::$_1, bool (std::shared_ptr&)>>(std::__function::__policy_storage const*, std::shared_ptr&) @ 0x0000000015f9837e 21. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000165d6fc3 22. /build/src/Storages/StorageReplicatedMergeTree.cpp:3872: DB::StorageReplicatedMergeTree::processQueueEntry(std::shared_ptr) @ 0x0000000015efc18a 23. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001624c1b2 24. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000162f9c70 25. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x00000000162fa55a 26. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc6653 27. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000000fccc4c3 28. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc3d92 29. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fcca080 30. ? @ 0x00007fbc6213eac3 31. ? @ 0x00007fbc621d0850 (version 25.3.6.10636.altinitytest (altinity build)) 2025.07.28 11:57:00.218988 [ 3967 ] {} test_13.rmt2 (7f9b740d-015c-470e-8cc6-8ba33be0dc63): auto DB::StorageReplicatedMergeTree::processQueueEntry(ReplicatedMergeTreeQueue::SelectedEntryPtr)::(anonymous class)::operator()(LogEntryPtr &) const: Code: 86. DB::HTTPException: Received error from remote server http://146b4357c08d:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Ftest%2F01165%2Ftest_13%2Frmt%2Freplicas%2F1&part=20250728_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.6.10636.altinitytest (altinity build)) '. (RECEIVED_ERROR_FROM_REMOTE_IO_SERVER), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.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 const&, int&&, String const&, unsigned long&&, String const&) @ 0x000000000feda8d9 4. /build/src/IO/HTTPCommon.cpp:104: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x000000000feda6e2 5. /build/src/IO/HTTPCommon.cpp:93: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x000000000feda537 6. /build/src/IO/ReadWriteBufferFromHTTP.cpp:277: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x000000001184a4c4 7. /build/src/IO/ReadWriteBufferFromHTTP.cpp:285: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x000000001184a615 8. /build/src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x000000001184ae59 9. /build/src/IO/ReadWriteBufferFromHTTP.cpp:472: void std::__function::__policy_invoker::__call_impl[abi:se190107]>(std::__function::__policy_storage const*) @ 0x000000001184cedd 10. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001184858b 11. /build/src/IO/ReadWriteBufferFromHTTP.cpp:465: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x000000001184bf0b 12. /build/src/IO/ReadBuffer.h:60: DB::ReadBuffer::next() @ 0x000000000a148c7b 13. /build/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) @ 0x0000000011849fb2 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]>&)>&, 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&) @ 0x0000000011841980 15. /build/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) @ 0x000000001621208e 16. /build/src/Storages/StorageReplicatedMergeTree.cpp:5228: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl[abi:se190107] const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000015f9a5fe 17. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000015ed8bfd 18. /build/src/Storages/StorageReplicatedMergeTree.cpp:2514: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x0000000015ec9aab 19. /build/src/Storages/StorageReplicatedMergeTree.cpp:2349: DB::StorageReplicatedMergeTree::executeLogEntry(DB::ReplicatedMergeTreeLogEntry&) @ 0x0000000015eba91b 20. /build/src/Storages/StorageReplicatedMergeTree.cpp:3876: bool std::__function::__policy_invoker&)>::__call_impl[abi:se190107])::$_1, bool (std::shared_ptr&)>>(std::__function::__policy_storage const*, std::shared_ptr&) @ 0x0000000015f9837e 21. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000165d6fc3 22. /build/src/Storages/StorageReplicatedMergeTree.cpp:3872: DB::StorageReplicatedMergeTree::processQueueEntry(std::shared_ptr) @ 0x0000000015efc18a 23. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001624c1b2 24. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000162f9c70 25. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x00000000162fa55a 26. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc6653 27. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000000fccc4c3 28. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc3d92 29. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fcca080 30. ? @ 0x00007fbc6213eac3 31. ? @ 0x00007fbc621d0850 (version 25.3.6.10636.altinitytest (altinity build)) 2025.07.28 11:57:00.252251 [ 3618 ] {} RefreshTask: test_pjnlliml.h: Refresh failed (attempt 1/3): 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. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000fccaeeb 4. /build/src/Common/ThreadPool.cpp:275: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000fccc813 5. /build/src/Common/ThreadPool.cpp:308: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fcc8286 6. /build/src/Common/ThreadPool.cpp:494: ThreadPoolImpl>::scheduleOrThrowOnError(std::function, Priority) @ 0x000000000fcc7a0e 7. /build/src/Common/threadPoolCallbackRunner.h:188: DB::ThreadPoolCallbackRunnerLocal>, std::function>::operator()(std::function&&, Priority, std::optional) @ 0x00000000119df78e 8. /build/src/Storages/MergeTree/MergeTreeData.cpp:1923: DB::MergeTreeData::loadDataParts(bool, std::optional, std::equal_to, std::allocator>>) @ 0x0000000016314fbd 9. /build/src/Storages/StorageMergeTree.cpp:161: 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>) @ 0x0000000016632c15 10. /build/contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: std::shared_ptr std::allocate_shared[abi:se190107], 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>&&) @ 0x00000000166326f0 11. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:851: DB::create(DB::StorageFactory::Arguments const&) @ 0x000000001662f01d 12. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000015d81ea2 13. /build/src/Interpreters/InterpreterCreateQuery.cpp:1945: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x00000000149009bb 14. /build/src/Interpreters/InterpreterCreateQuery.cpp:2125: DB::InterpreterCreateQuery::doCreateOrReplaceTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, DB::LoadingStrictnessLevel) @ 0x00000000148fcd0a 15. /build/src/Interpreters/InterpreterCreateQuery.cpp:1739: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000148f9a85 16. /build/src/Interpreters/InterpreterCreateQuery.cpp:2352: DB::InterpreterCreateQuery::execute() @ 0x0000000014905a41 17. /build/src/Storages/StorageMaterializedView.cpp:547: DB::StorageMaterializedView::prepareRefresh(bool, std::shared_ptr, std::optional&) const @ 0x0000000015e208d3 18. /build/src/Storages/MaterializedView/RefreshTask.cpp:649: DB::RefreshTask::executeRefreshUnlocked(bool, int) @ 0x0000000016792338 19. /build/src/Storages/MaterializedView/RefreshTask.cpp:542: DB::RefreshTask::refreshTask() @ 0x000000001678e034 20. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000139630d4 21. /build/src/Core/BackgroundSchedulePool.cpp:308: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001396616a 22. /build/src/Core/BackgroundSchedulePool.cpp:171: void std::__function::__policy_invoker::__call_impl[abi:se190107]::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_1>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_1&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001396690a 23. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc3d92 24. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fcca080 25. ? @ 0x00007fbc6213eac3 26. ? @ 0x00007fbc621d0850 (version 25.3.6.10636.altinitytest (altinity build)) 2025.07.28 11:57:01.165591 [ 3968 ] {} test_13.rmt2 (7f9b740d-015c-470e-8cc6-8ba33be0dc63): auto DB::StorageReplicatedMergeTree::processQueueEntry(ReplicatedMergeTreeQueue::SelectedEntryPtr)::(anonymous class)::operator()(LogEntryPtr &) const: Code: 86. DB::HTTPException: Received error from remote server http://146b4357c08d:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Ftest%2F01165%2Ftest_13%2Frmt%2Freplicas%2F1&part=20250728_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.6.10636.altinitytest (altinity build)) '. (RECEIVED_ERROR_FROM_REMOTE_IO_SERVER), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.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 const&, int&&, String const&, unsigned long&&, String const&) @ 0x000000000feda8d9 4. /build/src/IO/HTTPCommon.cpp:104: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x000000000feda6e2 5. /build/src/IO/HTTPCommon.cpp:93: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x000000000feda537 6. /build/src/IO/ReadWriteBufferFromHTTP.cpp:277: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x000000001184a4c4 7. /build/src/IO/ReadWriteBufferFromHTTP.cpp:285: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x000000001184a615 8. /build/src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x000000001184ae59 9. /build/src/IO/ReadWriteBufferFromHTTP.cpp:472: void std::__function::__policy_invoker::__call_impl[abi:se190107]>(std::__function::__policy_storage const*) @ 0x000000001184cedd 10. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001184858b 11. /build/src/IO/ReadWriteBufferFromHTTP.cpp:465: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x000000001184bf0b 12. /build/src/IO/ReadBuffer.h:60: DB::ReadBuffer::next() @ 0x000000000a148c7b 13. /build/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) @ 0x0000000011849fb2 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]>&)>&, 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&) @ 0x0000000011841980 15. /build/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) @ 0x000000001621208e 16. /build/src/Storages/StorageReplicatedMergeTree.cpp:5228: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl[abi:se190107] const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000015f9a5fe 17. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000015ed8bfd 18. /build/src/Storages/StorageReplicatedMergeTree.cpp:2514: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x0000000015ec9aab 19. /build/src/Storages/StorageReplicatedMergeTree.cpp:2349: DB::StorageReplicatedMergeTree::executeLogEntry(DB::ReplicatedMergeTreeLogEntry&) @ 0x0000000015eba91b 20. /build/src/Storages/StorageReplicatedMergeTree.cpp:3876: bool std::__function::__policy_invoker&)>::__call_impl[abi:se190107])::$_1, bool (std::shared_ptr&)>>(std::__function::__policy_storage const*, std::shared_ptr&) @ 0x0000000015f9837e 21. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000165d6fc3 22. /build/src/Storages/StorageReplicatedMergeTree.cpp:3872: DB::StorageReplicatedMergeTree::processQueueEntry(std::shared_ptr) @ 0x0000000015efc18a 23. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001624c1b2 24. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000162f9c70 25. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x00000000162fa55a 26. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc6653 27. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000000fccc4c3 28. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc3d92 29. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fcca080 30. ? @ 0x00007fbc6213eac3 31. ? @ 0x00007fbc621d0850 (version 25.3.6.10636.altinitytest (altinity build)) 2025.07.28 11:57:01.685952 [ 3964 ] {} test_13.rmt2 (7f9b740d-015c-470e-8cc6-8ba33be0dc63): auto DB::StorageReplicatedMergeTree::processQueueEntry(ReplicatedMergeTreeQueue::SelectedEntryPtr)::(anonymous class)::operator()(LogEntryPtr &) const: Code: 86. DB::HTTPException: Received error from remote server http://146b4357c08d:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Ftest%2F01165%2Ftest_13%2Frmt%2Freplicas%2F1&part=20250728_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.6.10636.altinitytest (altinity build)) '. (RECEIVED_ERROR_FROM_REMOTE_IO_SERVER), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.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 const&, int&&, String const&, unsigned long&&, String const&) @ 0x000000000feda8d9 4. /build/src/IO/HTTPCommon.cpp:104: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x000000000feda6e2 5. /build/src/IO/HTTPCommon.cpp:93: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x000000000feda537 6. /build/src/IO/ReadWriteBufferFromHTTP.cpp:277: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x000000001184a4c4 7. /build/src/IO/ReadWriteBufferFromHTTP.cpp:285: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x000000001184a615 8. /build/src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x000000001184ae59 9. /build/src/IO/ReadWriteBufferFromHTTP.cpp:472: void std::__function::__policy_invoker::__call_impl[abi:se190107]>(std::__function::__policy_storage const*) @ 0x000000001184cedd 10. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001184858b 11. /build/src/IO/ReadWriteBufferFromHTTP.cpp:465: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x000000001184bf0b 12. /build/src/IO/ReadBuffer.h:60: DB::ReadBuffer::next() @ 0x000000000a148c7b 13. /build/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) @ 0x0000000011849fb2 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]>&)>&, 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&) @ 0x0000000011841980 15. /build/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) @ 0x000000001621208e 16. /build/src/Storages/StorageReplicatedMergeTree.cpp:5228: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl[abi:se190107] const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000015f9a5fe 17. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000015ed8bfd 18. /build/src/Storages/StorageReplicatedMergeTree.cpp:2514: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x0000000015ec9aab 19. /build/src/Storages/StorageReplicatedMergeTree.cpp:2349: DB::StorageReplicatedMergeTree::executeLogEntry(DB::ReplicatedMergeTreeLogEntry&) @ 0x0000000015eba91b 20. /build/src/Storages/StorageReplicatedMergeTree.cpp:3876: bool std::__function::__policy_invoker&)>::__call_impl[abi:se190107])::$_1, bool (std::shared_ptr&)>>(std::__function::__policy_storage const*, std::shared_ptr&) @ 0x0000000015f9837e 21. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000165d6fc3 22. /build/src/Storages/StorageReplicatedMergeTree.cpp:3872: DB::StorageReplicatedMergeTree::processQueueEntry(std::shared_ptr) @ 0x0000000015efc18a 23. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001624c1b2 24. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000162f9c70 25. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x00000000162fa55a 26. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc6653 27. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000000fccc4c3 28. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc3d92 29. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fcca080 30. ? @ 0x00007fbc6213eac3 31. ? @ 0x00007fbc621d0850 (version 25.3.6.10636.altinitytest (altinity build)) 2025.07.28 11:57:02.013700 [ 3961 ] {} test_13.rmt2 (7f9b740d-015c-470e-8cc6-8ba33be0dc63): auto DB::StorageReplicatedMergeTree::processQueueEntry(ReplicatedMergeTreeQueue::SelectedEntryPtr)::(anonymous class)::operator()(LogEntryPtr &) const: Code: 86. DB::HTTPException: Received error from remote server http://146b4357c08d:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Ftest%2F01165%2Ftest_13%2Frmt%2Freplicas%2F1&part=20250728_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.6.10636.altinitytest (altinity build)) '. (RECEIVED_ERROR_FROM_REMOTE_IO_SERVER), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.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 const&, int&&, String const&, unsigned long&&, String const&) @ 0x000000000feda8d9 4. /build/src/IO/HTTPCommon.cpp:104: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x000000000feda6e2 5. /build/src/IO/HTTPCommon.cpp:93: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x000000000feda537 6. /build/src/IO/ReadWriteBufferFromHTTP.cpp:277: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x000000001184a4c4 7. /build/src/IO/ReadWriteBufferFromHTTP.cpp:285: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x000000001184a615 8. /build/src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x000000001184ae59 9. /build/src/IO/ReadWriteBufferFromHTTP.cpp:472: void std::__function::__policy_invoker::__call_impl[abi:se190107]>(std::__function::__policy_storage const*) @ 0x000000001184cedd 10. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001184858b 11. /build/src/IO/ReadWriteBufferFromHTTP.cpp:465: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x000000001184bf0b 12. /build/src/IO/ReadBuffer.h:60: DB::ReadBuffer::next() @ 0x000000000a148c7b 13. /build/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) @ 0x0000000011849fb2 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]>&)>&, 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&) @ 0x0000000011841980 15. /build/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) @ 0x000000001621208e 16. /build/src/Storages/StorageReplicatedMergeTree.cpp:5228: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl[abi:se190107] const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000015f9a5fe 17. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000015ed8bfd 18. /build/src/Storages/StorageReplicatedMergeTree.cpp:2514: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x0000000015ec9aab 19. /build/src/Storages/StorageReplicatedMergeTree.cpp:2349: DB::StorageReplicatedMergeTree::executeLogEntry(DB::ReplicatedMergeTreeLogEntry&) @ 0x0000000015eba91b 20. /build/src/Storages/StorageReplicatedMergeTree.cpp:3876: bool std::__function::__policy_invoker&)>::__call_impl[abi:se190107])::$_1, bool (std::shared_ptr&)>>(std::__function::__policy_storage const*, std::shared_ptr&) @ 0x0000000015f9837e 21. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000165d6fc3 22. /build/src/Storages/StorageReplicatedMergeTree.cpp:3872: DB::StorageReplicatedMergeTree::processQueueEntry(std::shared_ptr) @ 0x0000000015efc18a 23. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001624c1b2 24. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000162f9c70 25. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x00000000162fa55a 26. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc6653 27. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000000fccc4c3 28. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc3d92 29. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fcca080 30. ? @ 0x00007fbc6213eac3 31. ? @ 0x00007fbc621d0850 (version 25.3.6.10636.altinitytest (altinity build)) 2025.07.28 11:57:02.466223 [ 3970 ] {} test_13.rmt2 (7f9b740d-015c-470e-8cc6-8ba33be0dc63): auto DB::StorageReplicatedMergeTree::processQueueEntry(ReplicatedMergeTreeQueue::SelectedEntryPtr)::(anonymous class)::operator()(LogEntryPtr &) const: Code: 86. DB::HTTPException: Received error from remote server http://146b4357c08d:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Ftest%2F01165%2Ftest_13%2Frmt%2Freplicas%2F1&part=20250728_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.6.10636.altinitytest (altinity build)) '. (RECEIVED_ERROR_FROM_REMOTE_IO_SERVER), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.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 const&, int&&, String const&, unsigned long&&, String const&) @ 0x000000000feda8d9 4. /build/src/IO/HTTPCommon.cpp:104: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x000000000feda6e2 5. /build/src/IO/HTTPCommon.cpp:93: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x000000000feda537 6. /build/src/IO/ReadWriteBufferFromHTTP.cpp:277: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x000000001184a4c4 7. /build/src/IO/ReadWriteBufferFromHTTP.cpp:285: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x000000001184a615 8. /build/src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x000000001184ae59 9. /build/src/IO/ReadWriteBufferFromHTTP.cpp:472: void std::__function::__policy_invoker::__call_impl[abi:se190107]>(std::__function::__policy_storage const*) @ 0x000000001184cedd 10. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001184858b 11. /build/src/IO/ReadWriteBufferFromHTTP.cpp:465: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x000000001184bf0b 12. /build/src/IO/ReadBuffer.h:60: DB::ReadBuffer::next() @ 0x000000000a148c7b 13. /build/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) @ 0x0000000011849fb2 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]>&)>&, 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&) @ 0x0000000011841980 15. /build/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) @ 0x000000001621208e 16. /build/src/Storages/StorageReplicatedMergeTree.cpp:5228: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl[abi:se190107] const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000015f9a5fe 17. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000015ed8bfd 18. /build/src/Storages/StorageReplicatedMergeTree.cpp:2514: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x0000000015ec9aab 19. /build/src/Storages/StorageReplicatedMergeTree.cpp:2349: DB::StorageReplicatedMergeTree::executeLogEntry(DB::ReplicatedMergeTreeLogEntry&) @ 0x0000000015eba91b 20. /build/src/Storages/StorageReplicatedMergeTree.cpp:3876: bool std::__function::__policy_invoker&)>::__call_impl[abi:se190107])::$_1, bool (std::shared_ptr&)>>(std::__function::__policy_storage const*, std::shared_ptr&) @ 0x0000000015f9837e 21. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000165d6fc3 22. /build/src/Storages/StorageReplicatedMergeTree.cpp:3872: DB::StorageReplicatedMergeTree::processQueueEntry(std::shared_ptr) @ 0x0000000015efc18a 23. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001624c1b2 24. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000162f9c70 25. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x00000000162fa55a 26. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc6653 27. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000000fccc4c3 28. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc3d92 29. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fcca080 30. ? @ 0x00007fbc6213eac3 31. ? @ 0x00007fbc621d0850 (version 25.3.6.10636.altinitytest (altinity build)) 2025.07.28 11:57:02.599151 [ 3960 ] {} test_13.rmt2 (7f9b740d-015c-470e-8cc6-8ba33be0dc63): auto DB::StorageReplicatedMergeTree::processQueueEntry(ReplicatedMergeTreeQueue::SelectedEntryPtr)::(anonymous class)::operator()(LogEntryPtr &) const: Code: 86. DB::HTTPException: Received error from remote server http://146b4357c08d:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Ftest%2F01165%2Ftest_13%2Frmt%2Freplicas%2F1&part=20250728_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.6.10636.altinitytest (altinity build)) '. (RECEIVED_ERROR_FROM_REMOTE_IO_SERVER), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.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 const&, int&&, String const&, unsigned long&&, String const&) @ 0x000000000feda8d9 4. /build/src/IO/HTTPCommon.cpp:104: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x000000000feda6e2 5. /build/src/IO/HTTPCommon.cpp:93: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x000000000feda537 6. /build/src/IO/ReadWriteBufferFromHTTP.cpp:277: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x000000001184a4c4 7. /build/src/IO/ReadWriteBufferFromHTTP.cpp:285: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x000000001184a615 8. /build/src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x000000001184ae59 9. /build/src/IO/ReadWriteBufferFromHTTP.cpp:472: void std::__function::__policy_invoker::__call_impl[abi:se190107]>(std::__function::__policy_storage const*) @ 0x000000001184cedd 10. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001184858b 11. /build/src/IO/ReadWriteBufferFromHTTP.cpp:465: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x000000001184bf0b 12. /build/src/IO/ReadBuffer.h:60: DB::ReadBuffer::next() @ 0x000000000a148c7b 13. /build/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) @ 0x0000000011849fb2 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]>&)>&, 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&) @ 0x0000000011841980 15. /build/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) @ 0x000000001621208e 16. /build/src/Storages/StorageReplicatedMergeTree.cpp:5228: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl[abi:se190107] const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000015f9a5fe 17. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000015ed8bfd 18. /build/src/Storages/StorageReplicatedMergeTree.cpp:2514: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x0000000015ec9aab 19. /build/src/Storages/StorageReplicatedMergeTree.cpp:2349: DB::StorageReplicatedMergeTree::executeLogEntry(DB::ReplicatedMergeTreeLogEntry&) @ 0x0000000015eba91b 20. /build/src/Storages/StorageReplicatedMergeTree.cpp:3876: bool std::__function::__policy_invoker&)>::__call_impl[abi:se190107])::$_1, bool (std::shared_ptr&)>>(std::__function::__policy_storage const*, std::shared_ptr&) @ 0x0000000015f9837e 21. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000165d6fc3 22. /build/src/Storages/StorageReplicatedMergeTree.cpp:3872: DB::StorageReplicatedMergeTree::processQueueEntry(std::shared_ptr) @ 0x0000000015efc18a 23. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001624c1b2 24. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000162f9c70 25. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x00000000162fa55a 26. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc6653 27. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000000fccc4c3 28. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc3d92 29. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fcca080 30. ? @ 0x00007fbc6213eac3 31. ? @ 0x00007fbc621d0850 (version 25.3.6.10636.altinitytest (altinity build)) 2025.07.28 11:57:03.610826 [ 3966 ] {} test_13.rmt2 (7f9b740d-015c-470e-8cc6-8ba33be0dc63): auto DB::StorageReplicatedMergeTree::processQueueEntry(ReplicatedMergeTreeQueue::SelectedEntryPtr)::(anonymous class)::operator()(LogEntryPtr &) const: Code: 86. DB::HTTPException: Received error from remote server http://146b4357c08d:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Ftest%2F01165%2Ftest_13%2Frmt%2Freplicas%2F1&part=20250728_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.6.10636.altinitytest (altinity build)) '. (RECEIVED_ERROR_FROM_REMOTE_IO_SERVER), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.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 const&, int&&, String const&, unsigned long&&, String const&) @ 0x000000000feda8d9 4. /build/src/IO/HTTPCommon.cpp:104: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x000000000feda6e2 5. /build/src/IO/HTTPCommon.cpp:93: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x000000000feda537 6. /build/src/IO/ReadWriteBufferFromHTTP.cpp:277: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x000000001184a4c4 7. /build/src/IO/ReadWriteBufferFromHTTP.cpp:285: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x000000001184a615 8. /build/src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x000000001184ae59 9. /build/src/IO/ReadWriteBufferFromHTTP.cpp:472: void std::__function::__policy_invoker::__call_impl[abi:se190107]>(std::__function::__policy_storage const*) @ 0x000000001184cedd 10. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001184858b 11. /build/src/IO/ReadWriteBufferFromHTTP.cpp:465: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x000000001184bf0b 12. /build/src/IO/ReadBuffer.h:60: DB::ReadBuffer::next() @ 0x000000000a148c7b 13. /build/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) @ 0x0000000011849fb2 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]>&)>&, 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&) @ 0x0000000011841980 15. /build/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) @ 0x000000001621208e 16. /build/src/Storages/StorageReplicatedMergeTree.cpp:5228: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl[abi:se190107] const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000015f9a5fe 17. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000015ed8bfd 18. /build/src/Storages/StorageReplicatedMergeTree.cpp:2514: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x0000000015ec9aab 19. /build/src/Storages/StorageReplicatedMergeTree.cpp:2349: DB::StorageReplicatedMergeTree::executeLogEntry(DB::ReplicatedMergeTreeLogEntry&) @ 0x0000000015eba91b 20. /build/src/Storages/StorageReplicatedMergeTree.cpp:3876: bool std::__function::__policy_invoker&)>::__call_impl[abi:se190107])::$_1, bool (std::shared_ptr&)>>(std::__function::__policy_storage const*, std::shared_ptr&) @ 0x0000000015f9837e 21. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000165d6fc3 22. /build/src/Storages/StorageReplicatedMergeTree.cpp:3872: DB::StorageReplicatedMergeTree::processQueueEntry(std::shared_ptr) @ 0x0000000015efc18a 23. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001624c1b2 24. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000162f9c70 25. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x00000000162fa55a 26. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc6653 27. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000000fccc4c3 28. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc3d92 29. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fcca080 30. ? @ 0x00007fbc6213eac3 31. ? @ 0x00007fbc621d0850 (version 25.3.6.10636.altinitytest (altinity build)) 2025.07.28 11:57:04.182986 [ 3963 ] {} test_13.rmt2 (7f9b740d-015c-470e-8cc6-8ba33be0dc63): auto DB::StorageReplicatedMergeTree::processQueueEntry(ReplicatedMergeTreeQueue::SelectedEntryPtr)::(anonymous class)::operator()(LogEntryPtr &) const: Code: 86. DB::HTTPException: Received error from remote server http://146b4357c08d:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Ftest%2F01165%2Ftest_13%2Frmt%2Freplicas%2F1&part=20250728_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.6.10636.altinitytest (altinity build)) '. (RECEIVED_ERROR_FROM_REMOTE_IO_SERVER), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.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 const&, int&&, String const&, unsigned long&&, String const&) @ 0x000000000feda8d9 4. /build/src/IO/HTTPCommon.cpp:104: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x000000000feda6e2 5. /build/src/IO/HTTPCommon.cpp:93: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x000000000feda537 6. /build/src/IO/ReadWriteBufferFromHTTP.cpp:277: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x000000001184a4c4 7. /build/src/IO/ReadWriteBufferFromHTTP.cpp:285: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x000000001184a615 8. /build/src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x000000001184ae59 9. /build/src/IO/ReadWriteBufferFromHTTP.cpp:472: void std::__function::__policy_invoker::__call_impl[abi:se190107]>(std::__function::__policy_storage const*) @ 0x000000001184cedd 10. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001184858b 11. /build/src/IO/ReadWriteBufferFromHTTP.cpp:465: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x000000001184bf0b 12. /build/src/IO/ReadBuffer.h:60: DB::ReadBuffer::next() @ 0x000000000a148c7b 13. /build/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) @ 0x0000000011849fb2 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]>&)>&, 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&) @ 0x0000000011841980 15. /build/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) @ 0x000000001621208e 16. /build/src/Storages/StorageReplicatedMergeTree.cpp:5228: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl[abi:se190107] const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000015f9a5fe 17. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000015ed8bfd 18. /build/src/Storages/StorageReplicatedMergeTree.cpp:2514: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x0000000015ec9aab 19. /build/src/Storages/StorageReplicatedMergeTree.cpp:2349: DB::StorageReplicatedMergeTree::executeLogEntry(DB::ReplicatedMergeTreeLogEntry&) @ 0x0000000015eba91b 20. /build/src/Storages/StorageReplicatedMergeTree.cpp:3876: bool std::__function::__policy_invoker&)>::__call_impl[abi:se190107])::$_1, bool (std::shared_ptr&)>>(std::__function::__policy_storage const*, std::shared_ptr&) @ 0x0000000015f9837e 21. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000165d6fc3 22. /build/src/Storages/StorageReplicatedMergeTree.cpp:3872: DB::StorageReplicatedMergeTree::processQueueEntry(std::shared_ptr) @ 0x0000000015efc18a 23. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001624c1b2 24. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000162f9c70 25. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x00000000162fa55a 26. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc6653 27. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000000fccc4c3 28. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc3d92 29. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fcca080 30. ? @ 0x00007fbc6213eac3 31. ? @ 0x00007fbc621d0850 (version 25.3.6.10636.altinitytest (altinity build)) 2025.07.28 11:57:05.004509 [ 3285 ] {c7679245-3170-4616-a14a-a705cebbdd88} executeQuery: Code: 182. DB::Exception: Table expression test_i79n939k.merge1 AS __table1 does not support column __table1.Val in PREWHERE. In query SELECT Val FROM merge1 PREWHERE (Val = 65536) OR (Val = 2). (ILLEGAL_PREWHERE) (version 25.3.6.10636.altinitytest (altinity build)) (from [::1]:55530) (comment: 02527_storage_merge_prewhere_different_type.sql) (query 7, line 9) (in query: SELECT Val FROM merge1 PREWHERE Val = 65536 OR Val = 2;), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&) @ 0x000000000a10182b 4. /build/src/Planner/CollectTableExpressionData.cpp:272: DB::InDepthQueryTreeVisitor::visit(std::shared_ptr const&) @ 0x00000000142d02cd 5. /build/src/Analyzer/InDepthQueryTreeVisitor.h:90: DB::InDepthQueryTreeVisitor::visit(std::shared_ptr const&) @ 0x00000000142cffca 6. /build/src/Analyzer/InDepthQueryTreeVisitor.h:90: DB::InDepthQueryTreeVisitor::visit(std::shared_ptr const&) @ 0x00000000142cffca 7. /build/src/Analyzer/InDepthQueryTreeVisitor.h:90: DB::InDepthQueryTreeVisitor::visit(std::shared_ptr const&) @ 0x00000000142cffca 8. /build/src/Analyzer/InDepthQueryTreeVisitor.h:90: DB::InDepthQueryTreeVisitor::visit(std::shared_ptr const&) @ 0x00000000142cffca 9. /build/src/Planner/CollectTableExpressionData.cpp:364: DB::collectTableExpressionData(std::shared_ptr&, std::shared_ptr&) @ 0x00000000142cdf3f 10. /build/src/Planner/Planner.cpp:1486: DB::Planner::buildPlanForQueryNode() @ 0x0000000014978dec 11. /build/src/Planner/Planner.cpp:1308: DB::Planner::buildQueryPlanIfNeeded() @ 0x000000001497685c 12. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:255: DB::InterpreterSelectQueryAnalyzer::getQueryPlan() @ 0x000000001497476d 13. /build/src/Interpreters/executeQuery.cpp:1405: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88806 14. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 15. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 16. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 17. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 18. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 19. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 20. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 21. ? @ 0x00007fbc6213eac3 22. ? @ 0x00007fbc621d0850 2025.07.28 11:57:05.007367 [ 3285 ] {} TCPHandler: Code: 182. DB::Exception: Table expression test_i79n939k.merge1 AS __table1 does not support column __table1.Val in PREWHERE. In query SELECT Val FROM merge1 PREWHERE (Val = 65536) OR (Val = 2). (ILLEGAL_PREWHERE), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&) @ 0x000000000a10182b 4. /build/src/Planner/CollectTableExpressionData.cpp:272: DB::InDepthQueryTreeVisitor::visit(std::shared_ptr const&) @ 0x00000000142d02cd 5. /build/src/Analyzer/InDepthQueryTreeVisitor.h:90: DB::InDepthQueryTreeVisitor::visit(std::shared_ptr const&) @ 0x00000000142cffca 6. /build/src/Analyzer/InDepthQueryTreeVisitor.h:90: DB::InDepthQueryTreeVisitor::visit(std::shared_ptr const&) @ 0x00000000142cffca 7. /build/src/Analyzer/InDepthQueryTreeVisitor.h:90: DB::InDepthQueryTreeVisitor::visit(std::shared_ptr const&) @ 0x00000000142cffca 8. /build/src/Analyzer/InDepthQueryTreeVisitor.h:90: DB::InDepthQueryTreeVisitor::visit(std::shared_ptr const&) @ 0x00000000142cffca 9. /build/src/Planner/CollectTableExpressionData.cpp:364: DB::collectTableExpressionData(std::shared_ptr&, std::shared_ptr&) @ 0x00000000142cdf3f 10. /build/src/Planner/Planner.cpp:1486: DB::Planner::buildPlanForQueryNode() @ 0x0000000014978dec 11. /build/src/Planner/Planner.cpp:1308: DB::Planner::buildQueryPlanIfNeeded() @ 0x000000001497685c 12. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:255: DB::InterpreterSelectQueryAnalyzer::getQueryPlan() @ 0x000000001497476d 13. /build/src/Interpreters/executeQuery.cpp:1405: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88806 14. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 15. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 16. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 17. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 18. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 19. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 20. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 21. ? @ 0x00007fbc6213eac3 22. ? @ 0x00007fbc621d0850 2025.07.28 11:57:05.036973 [ 4581 ] {47d12579-ce4b-4f28-a324-a020c7fa0b01} executeQuery: Code: 190. DB::Exception: Lengths of all arrays passed to arrayEnumerateDense must be equal.: while executing 'FUNCTION arrayEnumerateDense(_CAST([]_Array(Nothing), 'Array(Nothing)'_String) :: 1, array(nothingNull(_CAST(NULL_Nullable(Nothing), 'Nullable(Nothing)'_String))) :: 2) -> arrayEnumerateDense(_CAST([]_Array(Nothing), 'Array(Nothing)'_String), array(nothingNull(_CAST(NULL_Nullable(Nothing), 'Nullable(Nothing)'_String)))) Array(UInt32) : 0'. (SIZES_OF_ARRAYS_DONT_MATCH) (version 25.3.6.10636.altinitytest (altinity build)) (from [::1]:55548) (comment: 00808_array_enumerate_segfault.sql) (query 3, line 3) (in query: SELECT arrayEnumerateDense([], [sequenceCount(NULL)]);), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x000000000a06b56b 4. /build/src/Functions/array/arrayEnumerateExtended.h:156: DB::FunctionArrayEnumerateExtended::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000f4fc064 5. /build/src/Functions/IFunctionAdaptors.cpp:10: DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000012d995fa 6. /build/src/Functions/IFunction.cpp:353: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d93b52 7. /build/src/Functions/IFunction.cpp:420: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d95059 8. /build/src/Functions/IFunction.cpp:498: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d95c72 9. /build/src/Interpreters/ExpressionActions.cpp:636: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x00000000145176f3 10. /build/src/Processors/Transforms/ExpressionTransform.cpp:25: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x0000000016c0b34c 11. /build/src/Processors/ISimpleTransform.h:33: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000011a9a453 12. /build/src/Processors/ISimpleTransform.cpp:89: DB::ISimpleTransform::work() @ 0x000000001699fca0 13. /build/src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x00000000169bd00f 14. /build/src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x00000000169b2105 15. /build/src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeSingleThread(unsigned long) @ 0x00000000169b23be 16. /build/src/Processors/Executors/PipelineExecutor.cpp:454: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x00000000169b0be7 17. /build/src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x00000000169b03f4 18. /build/src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:se190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169bfeab 19. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc3d92 20. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fcca080 21. ? @ 0x00007fbc6213eac3 22. ? @ 0x00007fbc621d0850 2025.07.28 11:57:05.039218 [ 4581 ] {} TCPHandler: Code: 190. DB::Exception: Lengths of all arrays passed to arrayEnumerateDense must be equal.: while executing 'FUNCTION arrayEnumerateDense(_CAST([]_Array(Nothing), 'Array(Nothing)'_String) :: 1, array(nothingNull(_CAST(NULL_Nullable(Nothing), 'Nullable(Nothing)'_String))) :: 2) -> arrayEnumerateDense(_CAST([]_Array(Nothing), 'Array(Nothing)'_String), array(nothingNull(_CAST(NULL_Nullable(Nothing), 'Nullable(Nothing)'_String)))) Array(UInt32) : 0'. (SIZES_OF_ARRAYS_DONT_MATCH), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x000000000a06b56b 4. /build/src/Functions/array/arrayEnumerateExtended.h:156: DB::FunctionArrayEnumerateExtended::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000f4fc064 5. /build/src/Functions/IFunctionAdaptors.cpp:10: DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000012d995fa 6. /build/src/Functions/IFunction.cpp:353: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d93b52 7. /build/src/Functions/IFunction.cpp:420: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d95059 8. /build/src/Functions/IFunction.cpp:498: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d95c72 9. /build/src/Interpreters/ExpressionActions.cpp:636: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x00000000145176f3 10. /build/src/Processors/Transforms/ExpressionTransform.cpp:25: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x0000000016c0b34c 11. /build/src/Processors/ISimpleTransform.h:33: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000011a9a453 12. /build/src/Processors/ISimpleTransform.cpp:89: DB::ISimpleTransform::work() @ 0x000000001699fca0 13. /build/src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x00000000169bd00f 14. /build/src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x00000000169b2105 15. /build/src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeSingleThread(unsigned long) @ 0x00000000169b23be 16. /build/src/Processors/Executors/PipelineExecutor.cpp:454: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x00000000169b0be7 17. /build/src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x00000000169b03f4 18. /build/src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:se190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169bfeab 19. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc3d92 20. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fcca080 21. ? @ 0x00007fbc6213eac3 22. ? @ 0x00007fbc621d0850 Job's origin stack trace: 0. /build/src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000000fc33b84 1. /build/src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000000fcc2ea7 2. /build/src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fcc535c 3. /build/src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000000fcc584d 4. /build/src/Common/ThreadPool.h:279: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x00000000169bf193 5. /build/src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x00000000169bf518 6. /build/src/Server/TCPHandler.cpp:1237: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x00000000168f1525 7. /build/src/Server/TCPHandler.cpp:678: DB::TCPHandler::runImpl() @ 0x00000000168e68e5 8. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 9. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 10. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 11. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 12. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 13. ? @ 0x00007fbc6213eac3 14. ? @ 0x00007fbc621d0850 2025.07.28 11:57:05.249995 [ 3285 ] {090da739-b29e-4753-b66d-d499cf59d088} executeQuery: Code: 48. DB::Exception: Truncate is not supported by storage Merge. (NOT_IMPLEMENTED) (version 25.3.6.10636.altinitytest (altinity build)) (from [::1]:55530) (comment: 02527_storage_merge_prewhere_different_type.sql) (query 11, line 15) (in query: DROP TABLE merge1;), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x000000000a06b56b 4. /build/src/Storages/IStorage.cpp:171: DB::IStorage::truncate(std::shared_ptr const&, std::shared_ptr const&, std::shared_ptr, DB::TableExclusiveLockHolder&) @ 0x0000000015d1ec7a 5. /build/src/Interpreters/InterpreterDropQuery.cpp:282: DB::InterpreterDropQuery::executeToTableImpl(std::shared_ptr const&, DB::ASTDropQuery&, std::shared_ptr&, StrongTypedef, DB::UUIDTag>&) @ 0x0000000014915304 6. /build/src/Interpreters/InterpreterDropQuery.cpp:118: DB::InterpreterDropQuery::executeToTable(DB::ASTDropQuery&) @ 0x00000000149137b4 7. /build/src/Interpreters/InterpreterDropQuery.cpp:91: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000014912f07 8. /build/src/Interpreters/InterpreterDropQuery.cpp:72: DB::InterpreterDropQuery::execute() @ 0x0000000014912b65 9. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88dc9 10. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 11. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 12. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 13. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 14. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 16. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 17. ? @ 0x00007fbc6213eac3 18. ? @ 0x00007fbc621d0850 2025.07.28 11:57:05.252428 [ 3285 ] {} 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. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x000000000a06b56b 4. /build/src/Storages/IStorage.cpp:171: DB::IStorage::truncate(std::shared_ptr const&, std::shared_ptr const&, std::shared_ptr, DB::TableExclusiveLockHolder&) @ 0x0000000015d1ec7a 5. /build/src/Interpreters/InterpreterDropQuery.cpp:282: DB::InterpreterDropQuery::executeToTableImpl(std::shared_ptr const&, DB::ASTDropQuery&, std::shared_ptr&, StrongTypedef, DB::UUIDTag>&) @ 0x0000000014915304 6. /build/src/Interpreters/InterpreterDropQuery.cpp:118: DB::InterpreterDropQuery::executeToTable(DB::ASTDropQuery&) @ 0x00000000149137b4 7. /build/src/Interpreters/InterpreterDropQuery.cpp:91: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000014912f07 8. /build/src/Interpreters/InterpreterDropQuery.cpp:72: DB::InterpreterDropQuery::execute() @ 0x0000000014912b65 9. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88dc9 10. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 11. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 12. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 13. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 14. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 16. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 17. ? @ 0x00007fbc6213eac3 18. ? @ 0x00007fbc621d0850 2025.07.28 11:57:05.258998 [ 3972 ] {} test_13.rmt2 (7f9b740d-015c-470e-8cc6-8ba33be0dc63): auto DB::StorageReplicatedMergeTree::processQueueEntry(ReplicatedMergeTreeQueue::SelectedEntryPtr)::(anonymous class)::operator()(LogEntryPtr &) const: Code: 86. DB::HTTPException: Received error from remote server http://146b4357c08d:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Ftest%2F01165%2Ftest_13%2Frmt%2Freplicas%2F1&part=20250728_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.6.10636.altinitytest (altinity build)) '. (RECEIVED_ERROR_FROM_REMOTE_IO_SERVER), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.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 const&, int&&, String const&, unsigned long&&, String const&) @ 0x000000000feda8d9 4. /build/src/IO/HTTPCommon.cpp:104: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x000000000feda6e2 5. /build/src/IO/HTTPCommon.cpp:93: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x000000000feda537 6. /build/src/IO/ReadWriteBufferFromHTTP.cpp:277: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x000000001184a4c4 7. /build/src/IO/ReadWriteBufferFromHTTP.cpp:285: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x000000001184a615 8. /build/src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x000000001184ae59 9. /build/src/IO/ReadWriteBufferFromHTTP.cpp:472: void std::__function::__policy_invoker::__call_impl[abi:se190107]>(std::__function::__policy_storage const*) @ 0x000000001184cedd 10. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001184858b 11. /build/src/IO/ReadWriteBufferFromHTTP.cpp:465: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x000000001184bf0b 12. /build/src/IO/ReadBuffer.h:60: DB::ReadBuffer::next() @ 0x000000000a148c7b 13. /build/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) @ 0x0000000011849fb2 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]>&)>&, 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&) @ 0x0000000011841980 15. /build/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) @ 0x000000001621208e 16. /build/src/Storages/StorageReplicatedMergeTree.cpp:5228: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl[abi:se190107] const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000015f9a5fe 17. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000015ed8bfd 18. /build/src/Storages/StorageReplicatedMergeTree.cpp:2514: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x0000000015ec9aab 19. /build/src/Storages/StorageReplicatedMergeTree.cpp:2349: DB::StorageReplicatedMergeTree::executeLogEntry(DB::ReplicatedMergeTreeLogEntry&) @ 0x0000000015eba91b 20. /build/src/Storages/StorageReplicatedMergeTree.cpp:3876: bool std::__function::__policy_invoker&)>::__call_impl[abi:se190107])::$_1, bool (std::shared_ptr&)>>(std::__function::__policy_storage const*, std::shared_ptr&) @ 0x0000000015f9837e 21. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000165d6fc3 22. /build/src/Storages/StorageReplicatedMergeTree.cpp:3872: DB::StorageReplicatedMergeTree::processQueueEntry(std::shared_ptr) @ 0x0000000015efc18a 23. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001624c1b2 24. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000162f9c70 25. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x00000000162fa55a 26. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc6653 27. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000000fccc4c3 28. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc3d92 29. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fcca080 30. ? @ 0x00007fbc6213eac3 31. ? @ 0x00007fbc621d0850 (version 25.3.6.10636.altinitytest (altinity build)) 2025.07.28 11:57:05.551784 [ 3976 ] {} test_13.rmt2 (7f9b740d-015c-470e-8cc6-8ba33be0dc63): auto DB::StorageReplicatedMergeTree::processQueueEntry(ReplicatedMergeTreeQueue::SelectedEntryPtr)::(anonymous class)::operator()(LogEntryPtr &) const: Code: 86. DB::HTTPException: Received error from remote server http://146b4357c08d:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Ftest%2F01165%2Ftest_13%2Frmt%2Freplicas%2F1&part=20250728_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.6.10636.altinitytest (altinity build)) '. (RECEIVED_ERROR_FROM_REMOTE_IO_SERVER), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.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 const&, int&&, String const&, unsigned long&&, String const&) @ 0x000000000feda8d9 4. /build/src/IO/HTTPCommon.cpp:104: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x000000000feda6e2 5. /build/src/IO/HTTPCommon.cpp:93: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x000000000feda537 6. /build/src/IO/ReadWriteBufferFromHTTP.cpp:277: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x000000001184a4c4 7. /build/src/IO/ReadWriteBufferFromHTTP.cpp:285: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x000000001184a615 8. /build/src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x000000001184ae59 9. /build/src/IO/ReadWriteBufferFromHTTP.cpp:472: void std::__function::__policy_invoker::__call_impl[abi:se190107]>(std::__function::__policy_storage const*) @ 0x000000001184cedd 10. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001184858b 11. /build/src/IO/ReadWriteBufferFromHTTP.cpp:465: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x000000001184bf0b 12. /build/src/IO/ReadBuffer.h:60: DB::ReadBuffer::next() @ 0x000000000a148c7b 13. /build/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) @ 0x0000000011849fb2 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]>&)>&, 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&) @ 0x0000000011841980 15. /build/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) @ 0x000000001621208e 16. /build/src/Storages/StorageReplicatedMergeTree.cpp:5228: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl[abi:se190107] const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000015f9a5fe 17. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000015ed8bfd 18. /build/src/Storages/StorageReplicatedMergeTree.cpp:2514: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x0000000015ec9aab 19. /build/src/Storages/StorageReplicatedMergeTree.cpp:2349: DB::StorageReplicatedMergeTree::executeLogEntry(DB::ReplicatedMergeTreeLogEntry&) @ 0x0000000015eba91b 20. /build/src/Storages/StorageReplicatedMergeTree.cpp:3876: bool std::__function::__policy_invoker&)>::__call_impl[abi:se190107])::$_1, bool (std::shared_ptr&)>>(std::__function::__policy_storage const*, std::shared_ptr&) @ 0x0000000015f9837e 21. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000165d6fc3 22. /build/src/Storages/StorageReplicatedMergeTree.cpp:3872: DB::StorageReplicatedMergeTree::processQueueEntry(std::shared_ptr) @ 0x0000000015efc18a 23. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001624c1b2 24. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000162f9c70 25. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x00000000162fa55a 26. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc6653 27. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000000fccc4c3 28. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc3d92 29. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fcca080 30. ? @ 0x00007fbc6213eac3 31. ? @ 0x00007fbc621d0850 (version 25.3.6.10636.altinitytest (altinity build)) 2025.07.28 11:57:05.675169 [ 4581 ] {62f62d2a-0d38-4234-8e84-f6bae9b1539a} 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.6.10636.altinitytest (altinity build)) (from [::1]:55568) (comment: 03217_filtering_in_storage_merge.sql) (query 1, line 1) (in query: CREATE TABLE test_03217_merge_replica_1 (`x` UInt32) ENGINE = ReplicatedMergeTree('/clickhouse/tables/{database}/test_03217_merge_replica', 'r1') ORDER BY x SETTINGS index_granularity = 32982, 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 = 0, compact_parts_max_bytes_to_buffer = 811348, compact_parts_max_granules_to_buffer = 212, compact_parts_merge_max_bytes_to_prefetch_part = 13218604, merge_max_block_size = 809, old_parts_lifetime = 336., prefer_fetch_merged_part_size_threshold = 10313763133, 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 = 29624297, 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 = false, marks_compress_block_size = 51158, primary_key_compress_block_size = 81595, 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. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000000a074fcb 4. /build/src/Databases/DatabaseReplicated.cpp:959: DB::DatabaseReplicated::checkTableEngine(DB::ASTCreateQuery const&, DB::ASTStorage&, std::shared_ptr) const @ 0x0000000013d9cf56 5. /build/src/Databases/DatabaseReplicated.cpp:1083: DB::DatabaseReplicated::checkQueryValid(std::shared_ptr const&, std::shared_ptr) const @ 0x0000000013d9ebb5 6. /build/src/Databases/DatabaseReplicated.cpp:1130: DB::DatabaseReplicated::tryEnqueueReplicatedDDL(std::shared_ptr const&, std::shared_ptr, DB::QueryFlags) @ 0x0000000013d9f10b 7. /build/src/Interpreters/InterpreterCreateQuery.cpp:1723: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000148f96f8 8. /build/src/Interpreters/InterpreterCreateQuery.cpp:2352: DB::InterpreterCreateQuery::execute() @ 0x0000000014905a41 9. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88dc9 10. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 11. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 12. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 13. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 14. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 16. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 17. ? @ 0x00007fbc6213eac3 18. ? @ 0x00007fbc621d0850 2025.07.28 11:57:05.679211 [ 4581 ] {} 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. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000000a074fcb 4. /build/src/Databases/DatabaseReplicated.cpp:959: DB::DatabaseReplicated::checkTableEngine(DB::ASTCreateQuery const&, DB::ASTStorage&, std::shared_ptr) const @ 0x0000000013d9cf56 5. /build/src/Databases/DatabaseReplicated.cpp:1083: DB::DatabaseReplicated::checkQueryValid(std::shared_ptr const&, std::shared_ptr) const @ 0x0000000013d9ebb5 6. /build/src/Databases/DatabaseReplicated.cpp:1130: DB::DatabaseReplicated::tryEnqueueReplicatedDDL(std::shared_ptr const&, std::shared_ptr, DB::QueryFlags) @ 0x0000000013d9f10b 7. /build/src/Interpreters/InterpreterCreateQuery.cpp:1723: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000148f96f8 8. /build/src/Interpreters/InterpreterCreateQuery.cpp:2352: DB::InterpreterCreateQuery::execute() @ 0x0000000014905a41 9. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88dc9 10. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 11. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 12. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 13. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 14. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 16. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 17. ? @ 0x00007fbc6213eac3 18. ? @ 0x00007fbc621d0850 2025.07.28 11:57:06.574952 [ 3969 ] {} test_13.rmt2 (7f9b740d-015c-470e-8cc6-8ba33be0dc63): auto DB::StorageReplicatedMergeTree::processQueueEntry(ReplicatedMergeTreeQueue::SelectedEntryPtr)::(anonymous class)::operator()(LogEntryPtr &) const: Code: 86. DB::HTTPException: Received error from remote server http://146b4357c08d:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Ftest%2F01165%2Ftest_13%2Frmt%2Freplicas%2F1&part=20250728_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.6.10636.altinitytest (altinity build)) '. (RECEIVED_ERROR_FROM_REMOTE_IO_SERVER), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.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 const&, int&&, String const&, unsigned long&&, String const&) @ 0x000000000feda8d9 4. /build/src/IO/HTTPCommon.cpp:104: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x000000000feda6e2 5. /build/src/IO/HTTPCommon.cpp:93: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x000000000feda537 6. /build/src/IO/ReadWriteBufferFromHTTP.cpp:277: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x000000001184a4c4 7. /build/src/IO/ReadWriteBufferFromHTTP.cpp:285: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x000000001184a615 8. /build/src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x000000001184ae59 9. /build/src/IO/ReadWriteBufferFromHTTP.cpp:472: void std::__function::__policy_invoker::__call_impl[abi:se190107]>(std::__function::__policy_storage const*) @ 0x000000001184cedd 10. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001184858b 11. /build/src/IO/ReadWriteBufferFromHTTP.cpp:465: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x000000001184bf0b 12. /build/src/IO/ReadBuffer.h:60: DB::ReadBuffer::next() @ 0x000000000a148c7b 13. /build/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) @ 0x0000000011849fb2 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]>&)>&, 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&) @ 0x0000000011841980 15. /build/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) @ 0x000000001621208e 16. /build/src/Storages/StorageReplicatedMergeTree.cpp:5228: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl[abi:se190107] const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000015f9a5fe 17. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000015ed8bfd 18. /build/src/Storages/StorageReplicatedMergeTree.cpp:2514: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x0000000015ec9aab 19. /build/src/Storages/StorageReplicatedMergeTree.cpp:2349: DB::StorageReplicatedMergeTree::executeLogEntry(DB::ReplicatedMergeTreeLogEntry&) @ 0x0000000015eba91b 20. /build/src/Storages/StorageReplicatedMergeTree.cpp:3876: bool std::__function::__policy_invoker&)>::__call_impl[abi:se190107])::$_1, bool (std::shared_ptr&)>>(std::__function::__policy_storage const*, std::shared_ptr&) @ 0x0000000015f9837e 21. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000165d6fc3 22. /build/src/Storages/StorageReplicatedMergeTree.cpp:3872: DB::StorageReplicatedMergeTree::processQueueEntry(std::shared_ptr) @ 0x0000000015efc18a 23. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001624c1b2 24. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000162f9c70 25. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x00000000162fa55a 26. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc6653 27. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000000fccc4c3 28. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc3d92 29. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fcca080 30. ? @ 0x00007fbc6213eac3 31. ? @ 0x00007fbc621d0850 (version 25.3.6.10636.altinitytest (altinity build)) 2025.07.28 11:57:07.472701 [ 3970 ] {} test_13.rmt2 (7f9b740d-015c-470e-8cc6-8ba33be0dc63): auto DB::StorageReplicatedMergeTree::processQueueEntry(ReplicatedMergeTreeQueue::SelectedEntryPtr)::(anonymous class)::operator()(LogEntryPtr &) const: Code: 86. DB::HTTPException: Received error from remote server http://146b4357c08d:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Ftest%2F01165%2Ftest_13%2Frmt%2Freplicas%2F1&part=20250728_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.6.10636.altinitytest (altinity build)) '. (RECEIVED_ERROR_FROM_REMOTE_IO_SERVER), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.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 const&, int&&, String const&, unsigned long&&, String const&) @ 0x000000000feda8d9 4. /build/src/IO/HTTPCommon.cpp:104: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x000000000feda6e2 5. /build/src/IO/HTTPCommon.cpp:93: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x000000000feda537 6. /build/src/IO/ReadWriteBufferFromHTTP.cpp:277: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x000000001184a4c4 7. /build/src/IO/ReadWriteBufferFromHTTP.cpp:285: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x000000001184a615 8. /build/src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x000000001184ae59 9. /build/src/IO/ReadWriteBufferFromHTTP.cpp:472: void std::__function::__policy_invoker::__call_impl[abi:se190107]>(std::__function::__policy_storage const*) @ 0x000000001184cedd 10. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001184858b 11. /build/src/IO/ReadWriteBufferFromHTTP.cpp:465: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x000000001184bf0b 12. /build/src/IO/ReadBuffer.h:60: DB::ReadBuffer::next() @ 0x000000000a148c7b 13. /build/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) @ 0x0000000011849fb2 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]>&)>&, 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&) @ 0x0000000011841980 15. /build/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) @ 0x000000001621208e 16. /build/src/Storages/StorageReplicatedMergeTree.cpp:5228: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl[abi:se190107] const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000015f9a5fe 17. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000015ed8bfd 18. /build/src/Storages/StorageReplicatedMergeTree.cpp:2514: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x0000000015ec9aab 19. /build/src/Storages/StorageReplicatedMergeTree.cpp:2349: DB::StorageReplicatedMergeTree::executeLogEntry(DB::ReplicatedMergeTreeLogEntry&) @ 0x0000000015eba91b 20. /build/src/Storages/StorageReplicatedMergeTree.cpp:3876: bool std::__function::__policy_invoker&)>::__call_impl[abi:se190107])::$_1, bool (std::shared_ptr&)>>(std::__function::__policy_storage const*, std::shared_ptr&) @ 0x0000000015f9837e 21. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000165d6fc3 22. /build/src/Storages/StorageReplicatedMergeTree.cpp:3872: DB::StorageReplicatedMergeTree::processQueueEntry(std::shared_ptr) @ 0x0000000015efc18a 23. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001624c1b2 24. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000162f9c70 25. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x00000000162fa55a 26. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc6653 27. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000000fccc4c3 28. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc3d92 29. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fcca080 30. ? @ 0x00007fbc6213eac3 31. ? @ 0x00007fbc621d0850 (version 25.3.6.10636.altinitytest (altinity build)) 2025.07.28 11:57:08.261584 [ 17256 ] {56b5b7c0-38a7-40c9-ba9a-020a2cc52f0a} executeQuery: Code: 219. DB::Exception: New table appeared in database being dropped or detached. Try again. (DATABASE_NOT_EMPTY) (version 25.3.6.10636.altinitytest (altinity build)) (from [::1]:44084) (comment: 00623_truncate_all_tables.sql) (in query: DROP DATABASE IF EXISTS test_xj4koi66 SYNC ), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000000a074fcb 4. /build/src/Interpreters/DatabaseCatalog.cpp:608: DB::DatabaseCatalog::detachDatabase(std::shared_ptr, String const&, bool, bool) @ 0x00000000144f41b9 5. /build/src/Interpreters/InterpreterDropQuery.cpp:482: DB::InterpreterDropQuery::executeToDatabaseImpl(DB::ASTDropQuery const&, std::shared_ptr&, std::vector, DB::UUIDTag>, std::allocator, DB::UUIDTag>>>&) @ 0x00000000149179be 6. /build/src/Interpreters/InterpreterDropQuery.cpp:363: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x0000000014913988 7. /build/src/Interpreters/InterpreterDropQuery.cpp:99: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000014913142 8. /build/src/Interpreters/InterpreterDropQuery.cpp:72: DB::InterpreterDropQuery::execute() @ 0x0000000014912b65 9. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88dc9 10. /build/src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x0000000014c8ca7b 11. /build/src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000001686da12 12. /build/src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x0000000016870807 13. /build/src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x0000000016907e99 14. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 15. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 16. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 17. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 18. ? @ 0x00007fbc6213eac3 19. ? @ 0x00007fbc621d0850 2025.07.28 11:57:08.268578 [ 17256 ] {56b5b7c0-38a7-40c9-ba9a-020a2cc52f0a} 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. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000000a074fcb 4. /build/src/Interpreters/DatabaseCatalog.cpp:608: DB::DatabaseCatalog::detachDatabase(std::shared_ptr, String const&, bool, bool) @ 0x00000000144f41b9 5. /build/src/Interpreters/InterpreterDropQuery.cpp:482: DB::InterpreterDropQuery::executeToDatabaseImpl(DB::ASTDropQuery const&, std::shared_ptr&, std::vector, DB::UUIDTag>, std::allocator, DB::UUIDTag>>>&) @ 0x00000000149179be 6. /build/src/Interpreters/InterpreterDropQuery.cpp:363: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x0000000014913988 7. /build/src/Interpreters/InterpreterDropQuery.cpp:99: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000014913142 8. /build/src/Interpreters/InterpreterDropQuery.cpp:72: DB::InterpreterDropQuery::execute() @ 0x0000000014912b65 9. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88dc9 10. /build/src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x0000000014c8ca7b 11. /build/src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000001686da12 12. /build/src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x0000000016870807 13. /build/src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x0000000016907e99 14. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 15. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 16. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 17. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 18. ? @ 0x00007fbc6213eac3 19. ? @ 0x00007fbc621d0850 (version 25.3.6.10636.altinitytest (altinity build)) 2025.07.28 11:57:08.332171 [ 3972 ] {} test_13.rmt2 (7f9b740d-015c-470e-8cc6-8ba33be0dc63): auto DB::StorageReplicatedMergeTree::processQueueEntry(ReplicatedMergeTreeQueue::SelectedEntryPtr)::(anonymous class)::operator()(LogEntryPtr &) const: Code: 86. DB::HTTPException: Received error from remote server http://146b4357c08d:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Ftest%2F01165%2Ftest_13%2Frmt%2Freplicas%2F1&part=20250728_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.6.10636.altinitytest (altinity build)) '. (RECEIVED_ERROR_FROM_REMOTE_IO_SERVER), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.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 const&, int&&, String const&, unsigned long&&, String const&) @ 0x000000000feda8d9 4. /build/src/IO/HTTPCommon.cpp:104: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x000000000feda6e2 5. /build/src/IO/HTTPCommon.cpp:93: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x000000000feda537 6. /build/src/IO/ReadWriteBufferFromHTTP.cpp:277: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x000000001184a4c4 7. /build/src/IO/ReadWriteBufferFromHTTP.cpp:285: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x000000001184a615 8. /build/src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x000000001184ae59 9. /build/src/IO/ReadWriteBufferFromHTTP.cpp:472: void std::__function::__policy_invoker::__call_impl[abi:se190107]>(std::__function::__policy_storage const*) @ 0x000000001184cedd 10. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001184858b 11. /build/src/IO/ReadWriteBufferFromHTTP.cpp:465: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x000000001184bf0b 12. /build/src/IO/ReadBuffer.h:60: DB::ReadBuffer::next() @ 0x000000000a148c7b 13. /build/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) @ 0x0000000011849fb2 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]>&)>&, 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&) @ 0x0000000011841980 15. /build/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) @ 0x000000001621208e 16. /build/src/Storages/StorageReplicatedMergeTree.cpp:5228: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl[abi:se190107] const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000015f9a5fe 17. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000015ed8bfd 18. /build/src/Storages/StorageReplicatedMergeTree.cpp:2514: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x0000000015ec9aab 19. /build/src/Storages/StorageReplicatedMergeTree.cpp:2349: DB::StorageReplicatedMergeTree::executeLogEntry(DB::ReplicatedMergeTreeLogEntry&) @ 0x0000000015eba91b 20. /build/src/Storages/StorageReplicatedMergeTree.cpp:3876: bool std::__function::__policy_invoker&)>::__call_impl[abi:se190107])::$_1, bool (std::shared_ptr&)>>(std::__function::__policy_storage const*, std::shared_ptr&) @ 0x0000000015f9837e 21. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000165d6fc3 22. /build/src/Storages/StorageReplicatedMergeTree.cpp:3872: DB::StorageReplicatedMergeTree::processQueueEntry(std::shared_ptr) @ 0x0000000015efc18a 23. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001624c1b2 24. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000162f9c70 25. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x00000000162fa55a 26. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc6653 27. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000000fccc4c3 28. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc3d92 29. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fcca080 30. ? @ 0x00007fbc6213eac3 31. ? @ 0x00007fbc621d0850 (version 25.3.6.10636.altinitytest (altinity build)) 2025.07.28 11:57:08.598013 [ 11851 ] {03cdbd64-e3a2-494d-9a92-5d92d8c86dcc} executeQuery: Code: 57. DB::Exception: Table test_15.test already exists. (TABLE_ALREADY_EXISTS) (version 25.3.6.10636.altinitytest (altinity build)) (from [::1]:55466) (comment: 03233_dynamic_in_functions.sql) (query 73, line 90) (in query: create table test (x String, d Dynamic) engine=Memory;), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000a06a8eb 4. /build/src/Interpreters/InterpreterCreateQuery.cpp:1824: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x0000000014901d53 5. /build/src/Interpreters/InterpreterCreateQuery.cpp:1743: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000148f9aa9 6. /build/src/Interpreters/InterpreterCreateQuery.cpp:2352: DB::InterpreterCreateQuery::execute() @ 0x0000000014905a41 7. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88dc9 8. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 9. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 10. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 11. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 12. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 13. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 14. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 15. ? @ 0x00007fbc6213eac3 16. ? @ 0x00007fbc621d0850 2025.07.28 11:57:08.600243 [ 11851 ] {} 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. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000a06a8eb 4. /build/src/Interpreters/InterpreterCreateQuery.cpp:1824: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x0000000014901d53 5. /build/src/Interpreters/InterpreterCreateQuery.cpp:1743: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000148f9aa9 6. /build/src/Interpreters/InterpreterCreateQuery.cpp:2352: DB::InterpreterCreateQuery::execute() @ 0x0000000014905a41 7. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88dc9 8. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 9. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 10. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 11. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 12. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 13. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 14. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 15. ? @ 0x00007fbc6213eac3 16. ? @ 0x00007fbc621d0850 2025.07.28 11:57:08.878755 [ 17270 ] {477ae45e-2cac-47b3-990f-364ea19b4c83} executeQuery: Code: 36. DB::Exception: Codec Delta is only applicable for data types of size 1, 2, 4, 8 bytes. Given type Decimal(38, 10). (BAD_ARGUMENTS) (version 25.3.6.10636.altinitytest (altinity build)) (from [::1]:55662) (comment: 01380_coded_delta_exception_code.sql) (query 1, line 1) (in query: CREATE TABLE delta_codec_synthetic (`id` Decimal(38, 10) CODEC(Delta, ZSTD(22))) ENGINE = MergeTree ORDER BY tuple() SETTINGS index_granularity = 42209, min_bytes_for_wide_part = 925966248, ratio_of_defaults_for_sparse_serialization = 1., replace_long_file_name_to_hash = false, max_file_name_length = 31, min_bytes_for_full_part_storage = 536870912, compact_parts_max_bytes_to_buffer = 78015950, compact_parts_max_granules_to_buffer = 92, compact_parts_merge_max_bytes_to_prefetch_part = 30196943, merge_max_block_size = 9466, 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 = 100, min_merge_bytes_to_use_direct_io = 1205293402, index_granularity_bytes = 17903911, 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 = false, cache_populated_by_fetch = false, marks_compress_block_size = 39958, primary_key_compress_block_size = 32698, 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. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x000000000a06b56b 4. /build/src/Compression/CompressionCodecDelta.cpp:183: std::shared_ptr std::__function::__policy_invoker (std::shared_ptr const&, DB::IDataType const*)>::__call_impl[abi:se190107] (std::shared_ptr const&, DB::IDataType const*)>>(std::__function::__policy_storage const*, std::shared_ptr const&, DB::IDataType const*) @ 0x00000000179487d3 5. /build/src/Compression/CompressionFactoryAdditions.cpp:135: void std::__function::__policy_invoker::__call_impl[abi:se190107] const&, std::shared_ptr const&, bool, bool, bool, bool) const::$_0, void (DB::ISerialization::SubstreamPath const&)>>(std::__function::__policy_storage const*, DB::ISerialization::SubstreamPath const&) @ 0x00000000179690ac 6. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000013c7aa09 7. /build/src/DataTypes/Serializations/ISerialization.cpp:104: DB::ISerialization::enumerateStreams(std::function const&, std::shared_ptr const&, COW::immutable_ptr const&) const @ 0x0000000013c7acfd 8. /build/src/Compression/CompressionFactoryAdditions.cpp:146: DB::CompressionCodecFactory::validateCodecAndGetPreprocessedAST(std::shared_ptr const&, std::shared_ptr const&, bool, bool, bool, bool) const @ 0x000000001796804d 9. /build/src/Interpreters/InterpreterCreateQuery.cpp:706: DB::InterpreterCreateQuery::getColumnsDescription(DB::ASTExpressionList const&, std::shared_ptr, DB::LoadingStrictnessLevel, bool) @ 0x00000000148ed211 10. /build/src/Interpreters/InterpreterCreateQuery.cpp:784: DB::InterpreterCreateQuery::getTablePropertiesAndNormalizeCreateQuery(DB::ASTCreateQuery&, DB::LoadingStrictnessLevel) const @ 0x00000000148ee1e4 11. /build/src/Interpreters/InterpreterCreateQuery.cpp:1657: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000148f901b 12. /build/src/Interpreters/InterpreterCreateQuery.cpp:2352: DB::InterpreterCreateQuery::execute() @ 0x0000000014905a41 13. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88dc9 14. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 15. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 16. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 17. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 18. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 19. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 20. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 21. ? @ 0x00007fbc6213eac3 22. ? @ 0x00007fbc621d0850 2025.07.28 11:57:08.884651 [ 17270 ] {} TCPHandler: Code: 36. DB::Exception: Codec Delta is only applicable for data types of size 1, 2, 4, 8 bytes. Given type Decimal(38, 10). (BAD_ARGUMENTS), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x000000000a06b56b 4. /build/src/Compression/CompressionCodecDelta.cpp:183: std::shared_ptr std::__function::__policy_invoker (std::shared_ptr const&, DB::IDataType const*)>::__call_impl[abi:se190107] (std::shared_ptr const&, DB::IDataType const*)>>(std::__function::__policy_storage const*, std::shared_ptr const&, DB::IDataType const*) @ 0x00000000179487d3 5. /build/src/Compression/CompressionFactoryAdditions.cpp:135: void std::__function::__policy_invoker::__call_impl[abi:se190107] const&, std::shared_ptr const&, bool, bool, bool, bool) const::$_0, void (DB::ISerialization::SubstreamPath const&)>>(std::__function::__policy_storage const*, DB::ISerialization::SubstreamPath const&) @ 0x00000000179690ac 6. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000013c7aa09 7. /build/src/DataTypes/Serializations/ISerialization.cpp:104: DB::ISerialization::enumerateStreams(std::function const&, std::shared_ptr const&, COW::immutable_ptr const&) const @ 0x0000000013c7acfd 8. /build/src/Compression/CompressionFactoryAdditions.cpp:146: DB::CompressionCodecFactory::validateCodecAndGetPreprocessedAST(std::shared_ptr const&, std::shared_ptr const&, bool, bool, bool, bool) const @ 0x000000001796804d 9. /build/src/Interpreters/InterpreterCreateQuery.cpp:706: DB::InterpreterCreateQuery::getColumnsDescription(DB::ASTExpressionList const&, std::shared_ptr, DB::LoadingStrictnessLevel, bool) @ 0x00000000148ed211 10. /build/src/Interpreters/InterpreterCreateQuery.cpp:784: DB::InterpreterCreateQuery::getTablePropertiesAndNormalizeCreateQuery(DB::ASTCreateQuery&, DB::LoadingStrictnessLevel) const @ 0x00000000148ee1e4 11. /build/src/Interpreters/InterpreterCreateQuery.cpp:1657: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000148f901b 12. /build/src/Interpreters/InterpreterCreateQuery.cpp:2352: DB::InterpreterCreateQuery::execute() @ 0x0000000014905a41 13. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88dc9 14. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 15. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 16. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 17. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 18. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 19. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 20. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 21. ? @ 0x00007fbc6213eac3 22. ? @ 0x00007fbc621d0850 2025.07.28 11:57:09.036769 [ 17270 ] {b8c96798-9c4e-493f-9284-0659ecd0ae91} executeQuery: Code: 36. DB::Exception: Codec DoubleDelta is only applicable for data types of size 1, 2, 4, 8 bytes. Given type Decimal(38, 10). (BAD_ARGUMENTS) (version 25.3.6.10636.altinitytest (altinity build)) (from [::1]:55662) (comment: 01380_coded_delta_exception_code.sql) (query 2, line 2) (in query: CREATE TABLE delta_codec_synthetic (`id` Decimal(38, 10) CODEC(DoubleDelta, ZSTD(22))) ENGINE = MergeTree ORDER BY tuple() SETTINGS index_granularity = 42209, min_bytes_for_wide_part = 925966248, ratio_of_defaults_for_sparse_serialization = 1., replace_long_file_name_to_hash = false, max_file_name_length = 31, min_bytes_for_full_part_storage = 536870912, compact_parts_max_bytes_to_buffer = 78015950, compact_parts_max_granules_to_buffer = 92, compact_parts_merge_max_bytes_to_prefetch_part = 30196943, merge_max_block_size = 9466, 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 = 100, min_merge_bytes_to_use_direct_io = 1205293402, index_granularity_bytes = 17903911, 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 = false, cache_populated_by_fetch = false, marks_compress_block_size = 39958, primary_key_compress_block_size = 32698, 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. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x000000000a06b56b 4. /build/src/Compression/CompressionCodecDoubleDelta.cpp:454: std::shared_ptr std::__function::__policy_invoker (std::shared_ptr const&, DB::IDataType const*)>::__call_impl[abi:se190107] (std::shared_ptr const&, DB::IDataType const*)>>(std::__function::__policy_storage const*, std::shared_ptr const&, DB::IDataType const*) @ 0x00000000179580f3 5. /build/src/Compression/CompressionFactoryAdditions.cpp:135: void std::__function::__policy_invoker::__call_impl[abi:se190107] const&, std::shared_ptr const&, bool, bool, bool, bool) const::$_0, void (DB::ISerialization::SubstreamPath const&)>>(std::__function::__policy_storage const*, DB::ISerialization::SubstreamPath const&) @ 0x00000000179690ac 6. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000013c7aa09 7. /build/src/DataTypes/Serializations/ISerialization.cpp:104: DB::ISerialization::enumerateStreams(std::function const&, std::shared_ptr const&, COW::immutable_ptr const&) const @ 0x0000000013c7acfd 8. /build/src/Compression/CompressionFactoryAdditions.cpp:146: DB::CompressionCodecFactory::validateCodecAndGetPreprocessedAST(std::shared_ptr const&, std::shared_ptr const&, bool, bool, bool, bool) const @ 0x000000001796804d 9. /build/src/Interpreters/InterpreterCreateQuery.cpp:706: DB::InterpreterCreateQuery::getColumnsDescription(DB::ASTExpressionList const&, std::shared_ptr, DB::LoadingStrictnessLevel, bool) @ 0x00000000148ed211 10. /build/src/Interpreters/InterpreterCreateQuery.cpp:784: DB::InterpreterCreateQuery::getTablePropertiesAndNormalizeCreateQuery(DB::ASTCreateQuery&, DB::LoadingStrictnessLevel) const @ 0x00000000148ee1e4 11. /build/src/Interpreters/InterpreterCreateQuery.cpp:1657: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000148f901b 12. /build/src/Interpreters/InterpreterCreateQuery.cpp:2352: DB::InterpreterCreateQuery::execute() @ 0x0000000014905a41 13. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88dc9 14. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 15. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 16. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 17. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 18. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 19. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 20. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 21. ? @ 0x00007fbc6213eac3 22. ? @ 0x00007fbc621d0850 2025.07.28 11:57:09.047680 [ 3968 ] {} test_13.rmt2 (7f9b740d-015c-470e-8cc6-8ba33be0dc63): auto DB::StorageReplicatedMergeTree::processQueueEntry(ReplicatedMergeTreeQueue::SelectedEntryPtr)::(anonymous class)::operator()(LogEntryPtr &) const: Code: 86. DB::HTTPException: Received error from remote server http://146b4357c08d:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Ftest%2F01165%2Ftest_13%2Frmt%2Freplicas%2F1&part=20250728_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.6.10636.altinitytest (altinity build)) '. (RECEIVED_ERROR_FROM_REMOTE_IO_SERVER), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.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 const&, int&&, String const&, unsigned long&&, String const&) @ 0x000000000feda8d9 4. /build/src/IO/HTTPCommon.cpp:104: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x000000000feda6e2 5. /build/src/IO/HTTPCommon.cpp:93: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x000000000feda537 6. /build/src/IO/ReadWriteBufferFromHTTP.cpp:277: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x000000001184a4c4 7. /build/src/IO/ReadWriteBufferFromHTTP.cpp:285: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x000000001184a615 8. /build/src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x000000001184ae59 9. /build/src/IO/ReadWriteBufferFromHTTP.cpp:472: void std::__function::__policy_invoker::__call_impl[abi:se190107]>(std::__function::__policy_storage const*) @ 0x000000001184cedd 10. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001184858b 11. /build/src/IO/ReadWriteBufferFromHTTP.cpp:465: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x000000001184bf0b 12. /build/src/IO/ReadBuffer.h:60: DB::ReadBuffer::next() @ 0x000000000a148c7b 13. /build/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) @ 0x0000000011849fb2 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]>&)>&, 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&) @ 0x0000000011841980 15. /build/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) @ 0x000000001621208e 16. /build/src/Storages/StorageReplicatedMergeTree.cpp:5228: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl[abi:se190107] const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000015f9a5fe 17. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000015ed8bfd 18. /build/src/Storages/StorageReplicatedMergeTree.cpp:2514: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x0000000015ec9aab 19. /build/src/Storages/StorageReplicatedMergeTree.cpp:2349: DB::StorageReplicatedMergeTree::executeLogEntry(DB::ReplicatedMergeTreeLogEntry&) @ 0x0000000015eba91b 20. /build/src/Storages/StorageReplicatedMergeTree.cpp:3876: bool std::__function::__policy_invoker&)>::__call_impl[abi:se190107])::$_1, bool (std::shared_ptr&)>>(std::__function::__policy_storage const*, std::shared_ptr&) @ 0x0000000015f9837e 21. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000165d6fc3 22. /build/src/Storages/StorageReplicatedMergeTree.cpp:3872: DB::StorageReplicatedMergeTree::processQueueEntry(std::shared_ptr) @ 0x0000000015efc18a 23. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001624c1b2 24. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000162f9c70 25. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x00000000162fa55a 26. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc6653 27. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000000fccc4c3 28. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc3d92 29. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fcca080 30. ? @ 0x00007fbc6213eac3 31. ? @ 0x00007fbc621d0850 (version 25.3.6.10636.altinitytest (altinity build)) 2025.07.28 11:57:09.049445 [ 17270 ] {} TCPHandler: Code: 36. DB::Exception: Codec DoubleDelta is only applicable for data types of size 1, 2, 4, 8 bytes. Given type Decimal(38, 10). (BAD_ARGUMENTS), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x000000000a06b56b 4. /build/src/Compression/CompressionCodecDoubleDelta.cpp:454: std::shared_ptr std::__function::__policy_invoker (std::shared_ptr const&, DB::IDataType const*)>::__call_impl[abi:se190107] (std::shared_ptr const&, DB::IDataType const*)>>(std::__function::__policy_storage const*, std::shared_ptr const&, DB::IDataType const*) @ 0x00000000179580f3 5. /build/src/Compression/CompressionFactoryAdditions.cpp:135: void std::__function::__policy_invoker::__call_impl[abi:se190107] const&, std::shared_ptr const&, bool, bool, bool, bool) const::$_0, void (DB::ISerialization::SubstreamPath const&)>>(std::__function::__policy_storage const*, DB::ISerialization::SubstreamPath const&) @ 0x00000000179690ac 6. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000013c7aa09 7. /build/src/DataTypes/Serializations/ISerialization.cpp:104: DB::ISerialization::enumerateStreams(std::function const&, std::shared_ptr const&, COW::immutable_ptr const&) const @ 0x0000000013c7acfd 8. /build/src/Compression/CompressionFactoryAdditions.cpp:146: DB::CompressionCodecFactory::validateCodecAndGetPreprocessedAST(std::shared_ptr const&, std::shared_ptr const&, bool, bool, bool, bool) const @ 0x000000001796804d 9. /build/src/Interpreters/InterpreterCreateQuery.cpp:706: DB::InterpreterCreateQuery::getColumnsDescription(DB::ASTExpressionList const&, std::shared_ptr, DB::LoadingStrictnessLevel, bool) @ 0x00000000148ed211 10. /build/src/Interpreters/InterpreterCreateQuery.cpp:784: DB::InterpreterCreateQuery::getTablePropertiesAndNormalizeCreateQuery(DB::ASTCreateQuery&, DB::LoadingStrictnessLevel) const @ 0x00000000148ee1e4 11. /build/src/Interpreters/InterpreterCreateQuery.cpp:1657: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000148f901b 12. /build/src/Interpreters/InterpreterCreateQuery.cpp:2352: DB::InterpreterCreateQuery::execute() @ 0x0000000014905a41 13. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88dc9 14. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 15. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 16. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 17. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 18. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 19. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 20. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 21. ? @ 0x00007fbc6213eac3 22. ? @ 0x00007fbc621d0850 2025.07.28 11:57:09.204298 [ 17270 ] {4d4ffa7b-d417-4708-b2bb-67bfb3d38f8b} executeQuery: Code: 36. DB::Exception: Codec Gorilla is only applicable for data types of size 1, 2, 4, 8 bytes. Given type Decimal(38, 10). (BAD_ARGUMENTS) (version 25.3.6.10636.altinitytest (altinity build)) (from [::1]:55662) (comment: 01380_coded_delta_exception_code.sql) (query 3, line 3) (in query: CREATE TABLE delta_codec_synthetic (`id` Decimal(38, 10) CODEC(Gorilla, ZSTD(22))) ENGINE = MergeTree ORDER BY tuple() SETTINGS index_granularity = 42209, min_bytes_for_wide_part = 925966248, ratio_of_defaults_for_sparse_serialization = 1., replace_long_file_name_to_hash = false, max_file_name_length = 31, min_bytes_for_full_part_storage = 536870912, compact_parts_max_bytes_to_buffer = 78015950, compact_parts_max_granules_to_buffer = 92, compact_parts_merge_max_bytes_to_prefetch_part = 30196943, merge_max_block_size = 9466, 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 = 100, min_merge_bytes_to_use_direct_io = 1205293402, index_granularity_bytes = 17903911, 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 = false, cache_populated_by_fetch = false, marks_compress_block_size = 39958, primary_key_compress_block_size = 32698, 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. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x000000000a06b56b 4. /build/src/Compression/CompressionCodecGorilla.cpp:350: std::shared_ptr std::__function::__policy_invoker (std::shared_ptr const&, DB::IDataType const*)>::__call_impl[abi:se190107] (std::shared_ptr const&, DB::IDataType const*)>>(std::__function::__policy_storage const*, std::shared_ptr const&, DB::IDataType const*) @ 0x000000001795ba33 5. /build/src/Compression/CompressionFactoryAdditions.cpp:135: void std::__function::__policy_invoker::__call_impl[abi:se190107] const&, std::shared_ptr const&, bool, bool, bool, bool) const::$_0, void (DB::ISerialization::SubstreamPath const&)>>(std::__function::__policy_storage const*, DB::ISerialization::SubstreamPath const&) @ 0x00000000179690ac 6. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000013c7aa09 7. /build/src/DataTypes/Serializations/ISerialization.cpp:104: DB::ISerialization::enumerateStreams(std::function const&, std::shared_ptr const&, COW::immutable_ptr const&) const @ 0x0000000013c7acfd 8. /build/src/Compression/CompressionFactoryAdditions.cpp:146: DB::CompressionCodecFactory::validateCodecAndGetPreprocessedAST(std::shared_ptr const&, std::shared_ptr const&, bool, bool, bool, bool) const @ 0x000000001796804d 9. /build/src/Interpreters/InterpreterCreateQuery.cpp:706: DB::InterpreterCreateQuery::getColumnsDescription(DB::ASTExpressionList const&, std::shared_ptr, DB::LoadingStrictnessLevel, bool) @ 0x00000000148ed211 10. /build/src/Interpreters/InterpreterCreateQuery.cpp:784: DB::InterpreterCreateQuery::getTablePropertiesAndNormalizeCreateQuery(DB::ASTCreateQuery&, DB::LoadingStrictnessLevel) const @ 0x00000000148ee1e4 11. /build/src/Interpreters/InterpreterCreateQuery.cpp:1657: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000148f901b 12. /build/src/Interpreters/InterpreterCreateQuery.cpp:2352: DB::InterpreterCreateQuery::execute() @ 0x0000000014905a41 13. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88dc9 14. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 15. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 16. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 17. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 18. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 19. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 20. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 21. ? @ 0x00007fbc6213eac3 22. ? @ 0x00007fbc621d0850 2025.07.28 11:57:09.207345 [ 17270 ] {} TCPHandler: Code: 36. DB::Exception: Codec Gorilla is only applicable for data types of size 1, 2, 4, 8 bytes. Given type Decimal(38, 10). (BAD_ARGUMENTS), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x000000000a06b56b 4. /build/src/Compression/CompressionCodecGorilla.cpp:350: std::shared_ptr std::__function::__policy_invoker (std::shared_ptr const&, DB::IDataType const*)>::__call_impl[abi:se190107] (std::shared_ptr const&, DB::IDataType const*)>>(std::__function::__policy_storage const*, std::shared_ptr const&, DB::IDataType const*) @ 0x000000001795ba33 5. /build/src/Compression/CompressionFactoryAdditions.cpp:135: void std::__function::__policy_invoker::__call_impl[abi:se190107] const&, std::shared_ptr const&, bool, bool, bool, bool) const::$_0, void (DB::ISerialization::SubstreamPath const&)>>(std::__function::__policy_storage const*, DB::ISerialization::SubstreamPath const&) @ 0x00000000179690ac 6. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000013c7aa09 7. /build/src/DataTypes/Serializations/ISerialization.cpp:104: DB::ISerialization::enumerateStreams(std::function const&, std::shared_ptr const&, COW::immutable_ptr const&) const @ 0x0000000013c7acfd 8. /build/src/Compression/CompressionFactoryAdditions.cpp:146: DB::CompressionCodecFactory::validateCodecAndGetPreprocessedAST(std::shared_ptr const&, std::shared_ptr const&, bool, bool, bool, bool) const @ 0x000000001796804d 9. /build/src/Interpreters/InterpreterCreateQuery.cpp:706: DB::InterpreterCreateQuery::getColumnsDescription(DB::ASTExpressionList const&, std::shared_ptr, DB::LoadingStrictnessLevel, bool) @ 0x00000000148ed211 10. /build/src/Interpreters/InterpreterCreateQuery.cpp:784: DB::InterpreterCreateQuery::getTablePropertiesAndNormalizeCreateQuery(DB::ASTCreateQuery&, DB::LoadingStrictnessLevel) const @ 0x00000000148ee1e4 11. /build/src/Interpreters/InterpreterCreateQuery.cpp:1657: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000148f901b 12. /build/src/Interpreters/InterpreterCreateQuery.cpp:2352: DB::InterpreterCreateQuery::execute() @ 0x0000000014905a41 13. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88dc9 14. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 15. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 16. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 17. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 18. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 19. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 20. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 21. ? @ 0x00007fbc6213eac3 22. ? @ 0x00007fbc621d0850 2025.07.28 11:57:09.265616 [ 17270 ] {829ea50b-88e0-4366-8b15-9a74a9891cbe} executeQuery: Code: 433. DB::Exception: Argument value for DoubleDelta codec can be 1, 2, 4 or 8, given 3. (ILLEGAL_CODEC_PARAMETER) (version 25.3.6.10636.altinitytest (altinity build)) (from [::1]:55662) (comment: 01380_coded_delta_exception_code.sql) (query 4, line 5) (in query: CREATE TABLE delta_codec_synthetic (`id` UInt64 CODEC(DoubleDelta(3), ZSTD(22))) ENGINE = MergeTree ORDER BY tuple() SETTINGS index_granularity = 42209, min_bytes_for_wide_part = 925966248, ratio_of_defaults_for_sparse_serialization = 1., replace_long_file_name_to_hash = false, max_file_name_length = 31, min_bytes_for_full_part_storage = 536870912, compact_parts_max_bytes_to_buffer = 78015950, compact_parts_max_granules_to_buffer = 92, compact_parts_merge_max_bytes_to_prefetch_part = 30196943, merge_max_block_size = 9466, 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 = 100, min_merge_bytes_to_use_direct_io = 1205293402, index_granularity_bytes = 17903911, 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 = false, cache_populated_by_fetch = false, marks_compress_block_size = 39958, primary_key_compress_block_size = 32698, 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. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type>, unsigned long&) @ 0x000000000b23df2b 4. /build/src/Compression/CompressionCodecDoubleDelta.cpp:573: std::shared_ptr std::__function::__policy_invoker (std::shared_ptr const&, DB::IDataType const*)>::__call_impl[abi:se190107] (std::shared_ptr const&, DB::IDataType const*)>>(std::__function::__policy_storage const*, std::shared_ptr const&, DB::IDataType const*) @ 0x0000000017958427 5. /build/src/Compression/CompressionFactoryAdditions.cpp:135: void std::__function::__policy_invoker::__call_impl[abi:se190107] const&, std::shared_ptr const&, bool, bool, bool, bool) const::$_0, void (DB::ISerialization::SubstreamPath const&)>>(std::__function::__policy_storage const*, DB::ISerialization::SubstreamPath const&) @ 0x00000000179690ac 6. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000013c7aa09 7. /build/src/DataTypes/Serializations/ISerialization.cpp:104: DB::ISerialization::enumerateStreams(std::function const&, std::shared_ptr const&, COW::immutable_ptr const&) const @ 0x0000000013c7acfd 8. /build/src/Compression/CompressionFactoryAdditions.cpp:146: DB::CompressionCodecFactory::validateCodecAndGetPreprocessedAST(std::shared_ptr const&, std::shared_ptr const&, bool, bool, bool, bool) const @ 0x000000001796804d 9. /build/src/Interpreters/InterpreterCreateQuery.cpp:706: DB::InterpreterCreateQuery::getColumnsDescription(DB::ASTExpressionList const&, std::shared_ptr, DB::LoadingStrictnessLevel, bool) @ 0x00000000148ed211 10. /build/src/Interpreters/InterpreterCreateQuery.cpp:784: DB::InterpreterCreateQuery::getTablePropertiesAndNormalizeCreateQuery(DB::ASTCreateQuery&, DB::LoadingStrictnessLevel) const @ 0x00000000148ee1e4 11. /build/src/Interpreters/InterpreterCreateQuery.cpp:1657: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000148f901b 12. /build/src/Interpreters/InterpreterCreateQuery.cpp:2352: DB::InterpreterCreateQuery::execute() @ 0x0000000014905a41 13. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88dc9 14. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 15. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 16. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 17. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 18. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 19. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 20. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 21. ? @ 0x00007fbc6213eac3 22. ? @ 0x00007fbc621d0850 2025.07.28 11:57:09.269666 [ 17270 ] {} TCPHandler: Code: 433. DB::Exception: Argument value for DoubleDelta codec can be 1, 2, 4 or 8, given 3. (ILLEGAL_CODEC_PARAMETER), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type>, unsigned long&) @ 0x000000000b23df2b 4. /build/src/Compression/CompressionCodecDoubleDelta.cpp:573: std::shared_ptr std::__function::__policy_invoker (std::shared_ptr const&, DB::IDataType const*)>::__call_impl[abi:se190107] (std::shared_ptr const&, DB::IDataType const*)>>(std::__function::__policy_storage const*, std::shared_ptr const&, DB::IDataType const*) @ 0x0000000017958427 5. /build/src/Compression/CompressionFactoryAdditions.cpp:135: void std::__function::__policy_invoker::__call_impl[abi:se190107] const&, std::shared_ptr const&, bool, bool, bool, bool) const::$_0, void (DB::ISerialization::SubstreamPath const&)>>(std::__function::__policy_storage const*, DB::ISerialization::SubstreamPath const&) @ 0x00000000179690ac 6. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000013c7aa09 7. /build/src/DataTypes/Serializations/ISerialization.cpp:104: DB::ISerialization::enumerateStreams(std::function const&, std::shared_ptr const&, COW::immutable_ptr const&) const @ 0x0000000013c7acfd 8. /build/src/Compression/CompressionFactoryAdditions.cpp:146: DB::CompressionCodecFactory::validateCodecAndGetPreprocessedAST(std::shared_ptr const&, std::shared_ptr const&, bool, bool, bool, bool) const @ 0x000000001796804d 9. /build/src/Interpreters/InterpreterCreateQuery.cpp:706: DB::InterpreterCreateQuery::getColumnsDescription(DB::ASTExpressionList const&, std::shared_ptr, DB::LoadingStrictnessLevel, bool) @ 0x00000000148ed211 10. /build/src/Interpreters/InterpreterCreateQuery.cpp:784: DB::InterpreterCreateQuery::getTablePropertiesAndNormalizeCreateQuery(DB::ASTCreateQuery&, DB::LoadingStrictnessLevel) const @ 0x00000000148ee1e4 11. /build/src/Interpreters/InterpreterCreateQuery.cpp:1657: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000148f901b 12. /build/src/Interpreters/InterpreterCreateQuery.cpp:2352: DB::InterpreterCreateQuery::execute() @ 0x0000000014905a41 13. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88dc9 14. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 15. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 16. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 17. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 18. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 19. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 20. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 21. ? @ 0x00007fbc6213eac3 22. ? @ 0x00007fbc621d0850 2025.07.28 11:57:09.363911 [ 17270 ] {f1463dd0-cf8c-4a12-9ee1-dcd3689f2742} executeQuery: Code: 433. DB::Exception: Gorilla codec argument must be unsigned integer. (ILLEGAL_CODEC_PARAMETER) (version 25.3.6.10636.altinitytest (altinity build)) (from [::1]:55662) (comment: 01380_coded_delta_exception_code.sql) (query 5, line 6) (in query: CREATE TABLE delta_codec_synthetic (`id` UInt64 CODEC(Gorilla('hello, world'), ZSTD(22))) ENGINE = MergeTree ORDER BY tuple() SETTINGS index_granularity = 42209, min_bytes_for_wide_part = 925966248, ratio_of_defaults_for_sparse_serialization = 1., replace_long_file_name_to_hash = false, max_file_name_length = 31, min_bytes_for_full_part_storage = 536870912, compact_parts_max_bytes_to_buffer = 78015950, compact_parts_max_granules_to_buffer = 92, compact_parts_merge_max_bytes_to_prefetch_part = 30196943, merge_max_block_size = 9466, 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 = 100, min_merge_bytes_to_use_direct_io = 1205293402, index_granularity_bytes = 17903911, 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 = false, cache_populated_by_fetch = false, marks_compress_block_size = 39958, primary_key_compress_block_size = 32698, 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. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000000a074fcb 4. /build/src/Compression/CompressionCodecGorilla.cpp:470: std::shared_ptr std::__function::__policy_invoker (std::shared_ptr const&, DB::IDataType const*)>::__call_impl[abi:se190107] (std::shared_ptr const&, DB::IDataType const*)>>(std::__function::__policy_storage const*, std::shared_ptr const&, DB::IDataType const*) @ 0x000000001795bbe8 5. /build/src/Compression/CompressionFactoryAdditions.cpp:135: void std::__function::__policy_invoker::__call_impl[abi:se190107] const&, std::shared_ptr const&, bool, bool, bool, bool) const::$_0, void (DB::ISerialization::SubstreamPath const&)>>(std::__function::__policy_storage const*, DB::ISerialization::SubstreamPath const&) @ 0x00000000179690ac 6. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000013c7aa09 7. /build/src/DataTypes/Serializations/ISerialization.cpp:104: DB::ISerialization::enumerateStreams(std::function const&, std::shared_ptr const&, COW::immutable_ptr const&) const @ 0x0000000013c7acfd 8. /build/src/Compression/CompressionFactoryAdditions.cpp:146: DB::CompressionCodecFactory::validateCodecAndGetPreprocessedAST(std::shared_ptr const&, std::shared_ptr const&, bool, bool, bool, bool) const @ 0x000000001796804d 9. /build/src/Interpreters/InterpreterCreateQuery.cpp:706: DB::InterpreterCreateQuery::getColumnsDescription(DB::ASTExpressionList const&, std::shared_ptr, DB::LoadingStrictnessLevel, bool) @ 0x00000000148ed211 10. /build/src/Interpreters/InterpreterCreateQuery.cpp:784: DB::InterpreterCreateQuery::getTablePropertiesAndNormalizeCreateQuery(DB::ASTCreateQuery&, DB::LoadingStrictnessLevel) const @ 0x00000000148ee1e4 11. /build/src/Interpreters/InterpreterCreateQuery.cpp:1657: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000148f901b 12. /build/src/Interpreters/InterpreterCreateQuery.cpp:2352: DB::InterpreterCreateQuery::execute() @ 0x0000000014905a41 13. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88dc9 14. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 15. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 16. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 17. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 18. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 19. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 20. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 21. ? @ 0x00007fbc6213eac3 22. ? @ 0x00007fbc621d0850 2025.07.28 11:57:09.376718 [ 17270 ] {} TCPHandler: Code: 433. DB::Exception: Gorilla codec argument must be unsigned integer. (ILLEGAL_CODEC_PARAMETER), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000000a074fcb 4. /build/src/Compression/CompressionCodecGorilla.cpp:470: std::shared_ptr std::__function::__policy_invoker (std::shared_ptr const&, DB::IDataType const*)>::__call_impl[abi:se190107] (std::shared_ptr const&, DB::IDataType const*)>>(std::__function::__policy_storage const*, std::shared_ptr const&, DB::IDataType const*) @ 0x000000001795bbe8 5. /build/src/Compression/CompressionFactoryAdditions.cpp:135: void std::__function::__policy_invoker::__call_impl[abi:se190107] const&, std::shared_ptr const&, bool, bool, bool, bool) const::$_0, void (DB::ISerialization::SubstreamPath const&)>>(std::__function::__policy_storage const*, DB::ISerialization::SubstreamPath const&) @ 0x00000000179690ac 6. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000013c7aa09 7. /build/src/DataTypes/Serializations/ISerialization.cpp:104: DB::ISerialization::enumerateStreams(std::function const&, std::shared_ptr const&, COW::immutable_ptr const&) const @ 0x0000000013c7acfd 8. /build/src/Compression/CompressionFactoryAdditions.cpp:146: DB::CompressionCodecFactory::validateCodecAndGetPreprocessedAST(std::shared_ptr const&, std::shared_ptr const&, bool, bool, bool, bool) const @ 0x000000001796804d 9. /build/src/Interpreters/InterpreterCreateQuery.cpp:706: DB::InterpreterCreateQuery::getColumnsDescription(DB::ASTExpressionList const&, std::shared_ptr, DB::LoadingStrictnessLevel, bool) @ 0x00000000148ed211 10. /build/src/Interpreters/InterpreterCreateQuery.cpp:784: DB::InterpreterCreateQuery::getTablePropertiesAndNormalizeCreateQuery(DB::ASTCreateQuery&, DB::LoadingStrictnessLevel) const @ 0x00000000148ee1e4 11. /build/src/Interpreters/InterpreterCreateQuery.cpp:1657: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000148f901b 12. /build/src/Interpreters/InterpreterCreateQuery.cpp:2352: DB::InterpreterCreateQuery::execute() @ 0x0000000014905a41 13. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88dc9 14. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 15. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 16. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 17. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 18. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 19. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 20. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 21. ? @ 0x00007fbc6213eac3 22. ? @ 0x00007fbc621d0850 2025.07.28 11:57:09.609184 [ 17243 ] {0cf675ed-75e1-4e6c-ba28-36d7005b7b2c} executeQuery: Code: 57. DB::Exception: Table test_15.test already exists. (TABLE_ALREADY_EXISTS) (version 25.3.6.10636.altinitytest (altinity build)) (from [::1]:55690) (comment: 02963_test_flexible_disk_configuration.sql) (query 2, line 4) (in query: CREATE TABLE test (`a` Int32) ENGINE = MergeTree ORDER BY tuple() SETTINGS disk = disk(name = '02963_custom_disk', type = object_storage, object_storage_type = local_blob_storage, path = './02963_test1/'), index_granularity = 14880, 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 = 536870912, compact_parts_max_bytes_to_buffer = 46392457, compact_parts_max_granules_to_buffer = 24, compact_parts_merge_max_bytes_to_prefetch_part = 20030921, merge_max_block_size = 16857, old_parts_lifetime = 480., prefer_fetch_merged_part_size_threshold = 10737418240, vertical_merge_algorithm_min_rows_to_activate = 11135, vertical_merge_algorithm_min_columns_to_activate = 17, min_merge_bytes_to_use_direct_io = 10737418240, index_granularity_bytes = 7912527, use_const_adaptive_granularity = true, enable_index_granularity_compression = true, concurrent_part_removal_threshold = 0, allow_vertical_merges_from_compact_to_wide_parts = true, enable_block_number_column = false, enable_block_offset_column = true, cache_populated_by_fetch = true, marks_compress_block_size = 92543, primary_key_compress_block_size = 56575, 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. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000a06a8eb 4. /build/src/Interpreters/InterpreterCreateQuery.cpp:1824: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x0000000014901d53 5. /build/src/Interpreters/InterpreterCreateQuery.cpp:1743: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000148f9aa9 6. /build/src/Interpreters/InterpreterCreateQuery.cpp:2352: DB::InterpreterCreateQuery::execute() @ 0x0000000014905a41 7. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88dc9 8. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 9. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 10. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 11. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 12. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 13. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 14. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 15. ? @ 0x00007fbc6213eac3 16. ? @ 0x00007fbc621d0850 2025.07.28 11:57:09.638312 [ 17243 ] {} 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. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000a06a8eb 4. /build/src/Interpreters/InterpreterCreateQuery.cpp:1824: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x0000000014901d53 5. /build/src/Interpreters/InterpreterCreateQuery.cpp:1743: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000148f9aa9 6. /build/src/Interpreters/InterpreterCreateQuery.cpp:2352: DB::InterpreterCreateQuery::execute() @ 0x0000000014905a41 7. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88dc9 8. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 9. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 10. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 11. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 12. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 13. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 14. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 15. ? @ 0x00007fbc6213eac3 16. ? @ 0x00007fbc621d0850 2025.07.28 11:57:09.840794 [ 4581 ] {0a1d53e0-eb65-4e16-acb6-c7a45ab96d93} 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.6.10636.altinitytest (altinity build)) (from [::1]:55612) (comment: 02319_lightweight_delete_on_merge_tree_compact_parts.sql) (query 9, line 16) (in query: DETACH TABLE merge_table_standard_delete;), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000000a074fcb 4. /build/src/Databases/DatabaseReplicated.cpp:1108: DB::DatabaseReplicated::checkQueryValid(std::shared_ptr const&, std::shared_ptr) const @ 0x0000000013d9ef48 5. /build/src/Databases/DatabaseReplicated.cpp:1130: DB::DatabaseReplicated::tryEnqueueReplicatedDDL(std::shared_ptr const&, std::shared_ptr, DB::QueryFlags) @ 0x0000000013d9f10b 6. /build/src/Interpreters/InterpreterDropQuery.cpp:226: DB::InterpreterDropQuery::executeToTableImpl(std::shared_ptr const&, DB::ASTDropQuery&, std::shared_ptr&, StrongTypedef, DB::UUIDTag>&) @ 0x0000000014914ed7 7. /build/src/Interpreters/InterpreterDropQuery.cpp:118: DB::InterpreterDropQuery::executeToTable(DB::ASTDropQuery&) @ 0x00000000149137b4 8. /build/src/Interpreters/InterpreterDropQuery.cpp:91: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000014912f07 9. /build/src/Interpreters/InterpreterDropQuery.cpp:72: DB::InterpreterDropQuery::execute() @ 0x0000000014912b65 10. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88dc9 11. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 12. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 13. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 14. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 15. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 16. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 17. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 18. ? @ 0x00007fbc6213eac3 19. ? @ 0x00007fbc621d0850 2025.07.28 11:57:09.862989 [ 4581 ] {} 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. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000000a074fcb 4. /build/src/Databases/DatabaseReplicated.cpp:1108: DB::DatabaseReplicated::checkQueryValid(std::shared_ptr const&, std::shared_ptr) const @ 0x0000000013d9ef48 5. /build/src/Databases/DatabaseReplicated.cpp:1130: DB::DatabaseReplicated::tryEnqueueReplicatedDDL(std::shared_ptr const&, std::shared_ptr, DB::QueryFlags) @ 0x0000000013d9f10b 6. /build/src/Interpreters/InterpreterDropQuery.cpp:226: DB::InterpreterDropQuery::executeToTableImpl(std::shared_ptr const&, DB::ASTDropQuery&, std::shared_ptr&, StrongTypedef, DB::UUIDTag>&) @ 0x0000000014914ed7 7. /build/src/Interpreters/InterpreterDropQuery.cpp:118: DB::InterpreterDropQuery::executeToTable(DB::ASTDropQuery&) @ 0x00000000149137b4 8. /build/src/Interpreters/InterpreterDropQuery.cpp:91: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000014912f07 9. /build/src/Interpreters/InterpreterDropQuery.cpp:72: DB::InterpreterDropQuery::execute() @ 0x0000000014912b65 10. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88dc9 11. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 12. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 13. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 14. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 15. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 16. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 17. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 18. ? @ 0x00007fbc6213eac3 19. ? @ 0x00007fbc621d0850 2025.07.28 11:57:09.942707 [ 3285 ] {d391922f-4baf-4b34-ba41-d859dae9f7a7} executeQuery: Code: 219. DB::Exception: New table appeared in database being dropped or detached. Try again. (DATABASE_NOT_EMPTY) (version 25.3.6.10636.altinitytest (altinity build)) (from [::1]:59414) (comment: 02319_lightweight_delete_on_merge_tree_compact_parts.sql) (in query: DROP DATABASE IF EXISTS test_ref6uw52 SYNC ), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000000a074fcb 4. /build/src/Interpreters/DatabaseCatalog.cpp:608: DB::DatabaseCatalog::detachDatabase(std::shared_ptr, String const&, bool, bool) @ 0x00000000144f41b9 5. /build/src/Interpreters/InterpreterDropQuery.cpp:482: DB::InterpreterDropQuery::executeToDatabaseImpl(DB::ASTDropQuery const&, std::shared_ptr&, std::vector, DB::UUIDTag>, std::allocator, DB::UUIDTag>>>&) @ 0x00000000149179be 6. /build/src/Interpreters/InterpreterDropQuery.cpp:363: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x0000000014913988 7. /build/src/Interpreters/InterpreterDropQuery.cpp:99: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000014913142 8. /build/src/Interpreters/InterpreterDropQuery.cpp:72: DB::InterpreterDropQuery::execute() @ 0x0000000014912b65 9. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88dc9 10. /build/src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x0000000014c8ca7b 11. /build/src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000001686da12 12. /build/src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x0000000016870807 13. /build/src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x0000000016907e99 14. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 15. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 16. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 17. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 18. ? @ 0x00007fbc6213eac3 19. ? @ 0x00007fbc621d0850 2025.07.28 11:57:09.952238 [ 3285 ] {d391922f-4baf-4b34-ba41-d859dae9f7a7} 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. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000000a074fcb 4. /build/src/Interpreters/DatabaseCatalog.cpp:608: DB::DatabaseCatalog::detachDatabase(std::shared_ptr, String const&, bool, bool) @ 0x00000000144f41b9 5. /build/src/Interpreters/InterpreterDropQuery.cpp:482: DB::InterpreterDropQuery::executeToDatabaseImpl(DB::ASTDropQuery const&, std::shared_ptr&, std::vector, DB::UUIDTag>, std::allocator, DB::UUIDTag>>>&) @ 0x00000000149179be 6. /build/src/Interpreters/InterpreterDropQuery.cpp:363: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x0000000014913988 7. /build/src/Interpreters/InterpreterDropQuery.cpp:99: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000014913142 8. /build/src/Interpreters/InterpreterDropQuery.cpp:72: DB::InterpreterDropQuery::execute() @ 0x0000000014912b65 9. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88dc9 10. /build/src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x0000000014c8ca7b 11. /build/src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000001686da12 12. /build/src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x0000000016870807 13. /build/src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x0000000016907e99 14. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 15. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 16. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 17. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 18. ? @ 0x00007fbc6213eac3 19. ? @ 0x00007fbc621d0850 (version 25.3.6.10636.altinitytest (altinity build)) 2025.07.28 11:57:09.965931 [ 3965 ] {} test_13.rmt2 (7f9b740d-015c-470e-8cc6-8ba33be0dc63): auto DB::StorageReplicatedMergeTree::processQueueEntry(ReplicatedMergeTreeQueue::SelectedEntryPtr)::(anonymous class)::operator()(LogEntryPtr &) const: Code: 86. DB::HTTPException: Received error from remote server http://146b4357c08d:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Ftest%2F01165%2Ftest_13%2Frmt%2Freplicas%2F1&part=20250728_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.6.10636.altinitytest (altinity build)) '. (RECEIVED_ERROR_FROM_REMOTE_IO_SERVER), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.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 const&, int&&, String const&, unsigned long&&, String const&) @ 0x000000000feda8d9 4. /build/src/IO/HTTPCommon.cpp:104: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x000000000feda6e2 5. /build/src/IO/HTTPCommon.cpp:93: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x000000000feda537 6. /build/src/IO/ReadWriteBufferFromHTTP.cpp:277: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x000000001184a4c4 7. /build/src/IO/ReadWriteBufferFromHTTP.cpp:285: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x000000001184a615 8. /build/src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x000000001184ae59 9. /build/src/IO/ReadWriteBufferFromHTTP.cpp:472: void std::__function::__policy_invoker::__call_impl[abi:se190107]>(std::__function::__policy_storage const*) @ 0x000000001184cedd 10. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001184858b 11. /build/src/IO/ReadWriteBufferFromHTTP.cpp:465: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x000000001184bf0b 12. /build/src/IO/ReadBuffer.h:60: DB::ReadBuffer::next() @ 0x000000000a148c7b 13. /build/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) @ 0x0000000011849fb2 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]>&)>&, 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&) @ 0x0000000011841980 15. /build/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) @ 0x000000001621208e 16. /build/src/Storages/StorageReplicatedMergeTree.cpp:5228: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl[abi:se190107] const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000015f9a5fe 17. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000015ed8bfd 18. /build/src/Storages/StorageReplicatedMergeTree.cpp:2514: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x0000000015ec9aab 19. /build/src/Storages/StorageReplicatedMergeTree.cpp:2349: DB::StorageReplicatedMergeTree::executeLogEntry(DB::ReplicatedMergeTreeLogEntry&) @ 0x0000000015eba91b 20. /build/src/Storages/StorageReplicatedMergeTree.cpp:3876: bool std::__function::__policy_invoker&)>::__call_impl[abi:se190107])::$_1, bool (std::shared_ptr&)>>(std::__function::__policy_storage const*, std::shared_ptr&) @ 0x0000000015f9837e 21. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000165d6fc3 22. /build/src/Storages/StorageReplicatedMergeTree.cpp:3872: DB::StorageReplicatedMergeTree::processQueueEntry(std::shared_ptr) @ 0x0000000015efc18a 23. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001624c1b2 24. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000162f9c70 25. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x00000000162fa55a 26. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc6653 27. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000000fccc4c3 28. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc3d92 29. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fcca080 30. ? @ 0x00007fbc6213eac3 31. ? @ 0x00007fbc621d0850 (version 25.3.6.10636.altinitytest (altinity build)) 2025.07.28 11:57:10.371208 [ 17255 ] {9c3bf554-8d5a-456f-b021-397c8332718f} executeQuery: Code: 57. DB::Exception: Table test_vy1tr888.tab already exists. (TABLE_ALREADY_EXISTS) (version 25.3.6.10636.altinitytest (altinity build)) (from [::1]:55594) (comment: 02461_mullable_pk_monotonicity_bug.sql) (query 42, line 49) (in query: CREATE TABLE tab (`x` DateTime) ENGINE = MergeTree ORDER BY x SETTINGS allow_nullable_key = 1, index_granularity = 2, min_bytes_for_wide_part = 235853450, 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 = 163815376, compact_parts_max_bytes_to_buffer = 477634272, compact_parts_max_granules_to_buffer = 1, compact_parts_merge_max_bytes_to_prefetch_part = 32193070, merge_max_block_size = 11325, old_parts_lifetime = 10., 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 = 9269718715, index_granularity_bytes = 20177941, use_const_adaptive_granularity = true, enable_index_granularity_compression = false, concurrent_part_removal_threshold = 59, 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 = 89788, primary_key_compress_block_size = 52436, 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. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000a06a8eb 4. /build/src/Interpreters/InterpreterCreateQuery.cpp:1824: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x0000000014901d53 5. /build/src/Interpreters/InterpreterCreateQuery.cpp:1743: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000148f9aa9 6. /build/src/Interpreters/InterpreterCreateQuery.cpp:2352: DB::InterpreterCreateQuery::execute() @ 0x0000000014905a41 7. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88dc9 8. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 9. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 10. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 11. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 12. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 13. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 14. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 15. ? @ 0x00007fbc6213eac3 16. ? @ 0x00007fbc621d0850 2025.07.28 11:57:10.389136 [ 17255 ] {} TCPHandler: Code: 57. DB::Exception: Table test_vy1tr888.tab already exists. (TABLE_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000a06a8eb 4. /build/src/Interpreters/InterpreterCreateQuery.cpp:1824: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x0000000014901d53 5. /build/src/Interpreters/InterpreterCreateQuery.cpp:1743: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000148f9aa9 6. /build/src/Interpreters/InterpreterCreateQuery.cpp:2352: DB::InterpreterCreateQuery::execute() @ 0x0000000014905a41 7. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88dc9 8. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 9. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 10. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 11. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 12. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 13. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 14. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 15. ? @ 0x00007fbc6213eac3 16. ? @ 0x00007fbc621d0850 2025.07.28 11:57:11.006615 [ 3974 ] {} test_13.rmt2 (7f9b740d-015c-470e-8cc6-8ba33be0dc63): auto DB::StorageReplicatedMergeTree::processQueueEntry(ReplicatedMergeTreeQueue::SelectedEntryPtr)::(anonymous class)::operator()(LogEntryPtr &) const: Code: 86. DB::HTTPException: Received error from remote server http://146b4357c08d:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Ftest%2F01165%2Ftest_13%2Frmt%2Freplicas%2F1&part=20250728_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.6.10636.altinitytest (altinity build)) '. (RECEIVED_ERROR_FROM_REMOTE_IO_SERVER), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.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 const&, int&&, String const&, unsigned long&&, String const&) @ 0x000000000feda8d9 4. /build/src/IO/HTTPCommon.cpp:104: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x000000000feda6e2 5. /build/src/IO/HTTPCommon.cpp:93: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x000000000feda537 6. /build/src/IO/ReadWriteBufferFromHTTP.cpp:277: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x000000001184a4c4 7. /build/src/IO/ReadWriteBufferFromHTTP.cpp:285: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x000000001184a615 8. /build/src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x000000001184ae59 9. /build/src/IO/ReadWriteBufferFromHTTP.cpp:472: void std::__function::__policy_invoker::__call_impl[abi:se190107]>(std::__function::__policy_storage const*) @ 0x000000001184cedd 10. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001184858b 11. /build/src/IO/ReadWriteBufferFromHTTP.cpp:465: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x000000001184bf0b 12. /build/src/IO/ReadBuffer.h:60: DB::ReadBuffer::next() @ 0x000000000a148c7b 13. /build/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) @ 0x0000000011849fb2 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]>&)>&, 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&) @ 0x0000000011841980 15. /build/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) @ 0x000000001621208e 16. /build/src/Storages/StorageReplicatedMergeTree.cpp:5228: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl[abi:se190107] const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000015f9a5fe 17. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000015ed8bfd 18. /build/src/Storages/StorageReplicatedMergeTree.cpp:2514: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x0000000015ec9aab 19. /build/src/Storages/StorageReplicatedMergeTree.cpp:2349: DB::StorageReplicatedMergeTree::executeLogEntry(DB::ReplicatedMergeTreeLogEntry&) @ 0x0000000015eba91b 20. /build/src/Storages/StorageReplicatedMergeTree.cpp:3876: bool std::__function::__policy_invoker&)>::__call_impl[abi:se190107])::$_1, bool (std::shared_ptr&)>>(std::__function::__policy_storage const*, std::shared_ptr&) @ 0x0000000015f9837e 21. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000165d6fc3 22. /build/src/Storages/StorageReplicatedMergeTree.cpp:3872: DB::StorageReplicatedMergeTree::processQueueEntry(std::shared_ptr) @ 0x0000000015efc18a 23. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001624c1b2 24. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000162f9c70 25. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x00000000162fa55a 26. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc6653 27. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000000fccc4c3 28. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc3d92 29. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fcca080 30. ? @ 0x00007fbc6213eac3 31. ? @ 0x00007fbc621d0850 (version 25.3.6.10636.altinitytest (altinity build)) 2025.07.28 11:57:11.968224 [ 3977 ] {} test_13.rmt2 (7f9b740d-015c-470e-8cc6-8ba33be0dc63): auto DB::StorageReplicatedMergeTree::processQueueEntry(ReplicatedMergeTreeQueue::SelectedEntryPtr)::(anonymous class)::operator()(LogEntryPtr &) const: Code: 86. DB::HTTPException: Received error from remote server http://146b4357c08d:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Ftest%2F01165%2Ftest_13%2Frmt%2Freplicas%2F1&part=20250728_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.6.10636.altinitytest (altinity build)) '. (RECEIVED_ERROR_FROM_REMOTE_IO_SERVER), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.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 const&, int&&, String const&, unsigned long&&, String const&) @ 0x000000000feda8d9 4. /build/src/IO/HTTPCommon.cpp:104: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x000000000feda6e2 5. /build/src/IO/HTTPCommon.cpp:93: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x000000000feda537 6. /build/src/IO/ReadWriteBufferFromHTTP.cpp:277: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x000000001184a4c4 7. /build/src/IO/ReadWriteBufferFromHTTP.cpp:285: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x000000001184a615 8. /build/src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x000000001184ae59 9. /build/src/IO/ReadWriteBufferFromHTTP.cpp:472: void std::__function::__policy_invoker::__call_impl[abi:se190107]>(std::__function::__policy_storage const*) @ 0x000000001184cedd 10. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001184858b 11. /build/src/IO/ReadWriteBufferFromHTTP.cpp:465: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x000000001184bf0b 12. /build/src/IO/ReadBuffer.h:60: DB::ReadBuffer::next() @ 0x000000000a148c7b 13. /build/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) @ 0x0000000011849fb2 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]>&)>&, 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&) @ 0x0000000011841980 15. /build/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) @ 0x000000001621208e 16. /build/src/Storages/StorageReplicatedMergeTree.cpp:5228: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl[abi:se190107] const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000015f9a5fe 17. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000015ed8bfd 18. /build/src/Storages/StorageReplicatedMergeTree.cpp:2514: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x0000000015ec9aab 19. /build/src/Storages/StorageReplicatedMergeTree.cpp:2349: DB::StorageReplicatedMergeTree::executeLogEntry(DB::ReplicatedMergeTreeLogEntry&) @ 0x0000000015eba91b 20. /build/src/Storages/StorageReplicatedMergeTree.cpp:3876: bool std::__function::__policy_invoker&)>::__call_impl[abi:se190107])::$_1, bool (std::shared_ptr&)>>(std::__function::__policy_storage const*, std::shared_ptr&) @ 0x0000000015f9837e 21. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000165d6fc3 22. /build/src/Storages/StorageReplicatedMergeTree.cpp:3872: DB::StorageReplicatedMergeTree::processQueueEntry(std::shared_ptr) @ 0x0000000015efc18a 23. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001624c1b2 24. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000162f9c70 25. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x00000000162fa55a 26. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc6653 27. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000000fccc4c3 28. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc3d92 29. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fcca080 30. ? @ 0x00007fbc6213eac3 31. ? @ 0x00007fbc621d0850 (version 25.3.6.10636.altinitytest (altinity build)) 2025.07.28 11:57:12.172493 [ 3962 ] {} test_13.rmt2 (7f9b740d-015c-470e-8cc6-8ba33be0dc63): auto DB::StorageReplicatedMergeTree::processQueueEntry(ReplicatedMergeTreeQueue::SelectedEntryPtr)::(anonymous class)::operator()(LogEntryPtr &) const: Code: 86. DB::HTTPException: Received error from remote server http://146b4357c08d:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Ftest%2F01165%2Ftest_13%2Frmt%2Freplicas%2F1&part=20250728_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.6.10636.altinitytest (altinity build)) '. (RECEIVED_ERROR_FROM_REMOTE_IO_SERVER), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.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 const&, int&&, String const&, unsigned long&&, String const&) @ 0x000000000feda8d9 4. /build/src/IO/HTTPCommon.cpp:104: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x000000000feda6e2 5. /build/src/IO/HTTPCommon.cpp:93: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x000000000feda537 6. /build/src/IO/ReadWriteBufferFromHTTP.cpp:277: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x000000001184a4c4 7. /build/src/IO/ReadWriteBufferFromHTTP.cpp:285: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x000000001184a615 8. /build/src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x000000001184ae59 9. /build/src/IO/ReadWriteBufferFromHTTP.cpp:472: void std::__function::__policy_invoker::__call_impl[abi:se190107]>(std::__function::__policy_storage const*) @ 0x000000001184cedd 10. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001184858b 11. /build/src/IO/ReadWriteBufferFromHTTP.cpp:465: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x000000001184bf0b 12. /build/src/IO/ReadBuffer.h:60: DB::ReadBuffer::next() @ 0x000000000a148c7b 13. /build/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) @ 0x0000000011849fb2 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]>&)>&, 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&) @ 0x0000000011841980 15. /build/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) @ 0x000000001621208e 16. /build/src/Storages/StorageReplicatedMergeTree.cpp:5228: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl[abi:se190107] const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000015f9a5fe 17. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000015ed8bfd 18. /build/src/Storages/StorageReplicatedMergeTree.cpp:2514: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x0000000015ec9aab 19. /build/src/Storages/StorageReplicatedMergeTree.cpp:2349: DB::StorageReplicatedMergeTree::executeLogEntry(DB::ReplicatedMergeTreeLogEntry&) @ 0x0000000015eba91b 20. /build/src/Storages/StorageReplicatedMergeTree.cpp:3876: bool std::__function::__policy_invoker&)>::__call_impl[abi:se190107])::$_1, bool (std::shared_ptr&)>>(std::__function::__policy_storage const*, std::shared_ptr&) @ 0x0000000015f9837e 21. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000165d6fc3 22. /build/src/Storages/StorageReplicatedMergeTree.cpp:3872: DB::StorageReplicatedMergeTree::processQueueEntry(std::shared_ptr) @ 0x0000000015efc18a 23. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001624c1b2 24. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000162f9c70 25. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x00000000162fa55a 26. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc6653 27. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000000fccc4c3 28. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc3d92 29. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fcca080 30. ? @ 0x00007fbc6213eac3 31. ? @ 0x00007fbc621d0850 (version 25.3.6.10636.altinitytest (altinity build)) 2025.07.28 11:57:12.282077 [ 17270 ] {09150157-1a9d-4595-89b0-c03b3d35b316} executeQuery: Code: 57. DB::Exception: Table test_15.test already exists. (TABLE_ALREADY_EXISTS) (version 25.3.6.10636.altinitytest (altinity build)) (from [::1]:41302) (comment: 03038_nested_dynamic_merges_small.gen.sql) (query 7, line 9) (in query: CREATE TABLE test (`id` UInt64, `d` Dynamic(max_types = 2)) ENGINE = MergeTree ORDER BY id SETTINGS min_rows_for_wide_part = 1000000000, min_bytes_for_wide_part = 10000000000, index_granularity = 39988, 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 = 186423754, compact_parts_max_granules_to_buffer = 123, compact_parts_merge_max_bytes_to_prefetch_part = 14976213, merge_max_block_size = 11082, old_parts_lifetime = 60., prefer_fetch_merged_part_size_threshold = 7681747592, vertical_merge_algorithm_min_rows_to_activate = 489853, vertical_merge_algorithm_min_columns_to_activate = 1, min_merge_bytes_to_use_direct_io = 1, index_granularity_bytes = 9730218, use_const_adaptive_granularity = false, enable_index_granularity_compression = false, concurrent_part_removal_threshold = 81, allow_vertical_merges_from_compact_to_wide_parts = true, enable_block_number_column = false, enable_block_offset_column = true, cache_populated_by_fetch = true, marks_compress_block_size = 63835, primary_key_compress_block_size = 88508, 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. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000a06a8eb 4. /build/src/Interpreters/InterpreterCreateQuery.cpp:1824: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x0000000014901d53 5. /build/src/Interpreters/InterpreterCreateQuery.cpp:1743: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000148f9aa9 6. /build/src/Interpreters/InterpreterCreateQuery.cpp:2352: DB::InterpreterCreateQuery::execute() @ 0x0000000014905a41 7. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88dc9 8. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 9. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 10. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 11. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 12. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 13. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 14. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 15. ? @ 0x00007fbc6213eac3 16. ? @ 0x00007fbc621d0850 2025.07.28 11:57:12.294094 [ 17270 ] {} 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. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000a06a8eb 4. /build/src/Interpreters/InterpreterCreateQuery.cpp:1824: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x0000000014901d53 5. /build/src/Interpreters/InterpreterCreateQuery.cpp:1743: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000148f9aa9 6. /build/src/Interpreters/InterpreterCreateQuery.cpp:2352: DB::InterpreterCreateQuery::execute() @ 0x0000000014905a41 7. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88dc9 8. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 9. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 10. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 11. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 12. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 13. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 14. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 15. ? @ 0x00007fbc6213eac3 16. ? @ 0x00007fbc621d0850 2025.07.28 11:57:12.333274 [ 3285 ] {0755b4ed-e870-4c47-8b8d-6a61ac1fb0d7} executeQuery: Code: 524. DB::Exception: Trying to ALTER DROP column n3 which is referenced by materialized view ['01746_merge_tree_mv']. (ALTER_OF_COLUMN_IS_FORBIDDEN) (version 25.3.6.10636.altinitytest (altinity build)) (from 0.0.0.0:0) (comment: 01746_forbid_drop_column_referenced_by_mv.sql) (in query: /* ddl_entry=query-0000000004 */ ALTER TABLE test_hz72qx47.`01746_merge_tree` (DROP COLUMN n3)), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000a06a8eb 4. /build/src/Storages/MergeTree/MergeTreeData.cpp:3765: DB::MergeTreeData::checkAlterIsPossible(DB::AlterCommands const&, std::shared_ptr) const @ 0x00000000163387c2 5. /build/src/Interpreters/InterpreterAlterQuery.cpp:215: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x00000000148deab3 6. /build/src/Interpreters/InterpreterAlterQuery.cpp:77: DB::InterpreterAlterQuery::execute() @ 0x00000000148dcb0d 7. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88dc9 8. /build/src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x0000000014c8ca7b 9. /build/src/Interpreters/DDLWorker.cpp:510: DB::DDLWorker::tryExecuteQuery(DB::DDLTaskBase&, std::shared_ptr const&, bool) @ 0x00000000144dab9e 10. /build/src/Interpreters/DDLWorker.cpp:675: DB::DDLWorker::processTask(DB::DDLTaskBase&, std::shared_ptr const&, bool) @ 0x00000000144d8ffe 11. /build/src/Databases/DatabaseReplicatedWorker.cpp:372: DB::DatabaseReplicatedDDLWorker::tryEnqueueAndExecuteEntry(DB::DDLLogEntry&, std::shared_ptr, bool) @ 0x0000000013dc29ab 12. /build/src/Databases/DatabaseReplicated.cpp:1139: DB::DatabaseReplicated::tryEnqueueReplicatedDDL(std::shared_ptr const&, std::shared_ptr, DB::QueryFlags) @ 0x0000000013d9f73c 13. /build/src/Interpreters/InterpreterAlterQuery.cpp:130: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x00000000148dd805 14. /build/src/Interpreters/InterpreterAlterQuery.cpp:77: DB::InterpreterAlterQuery::execute() @ 0x00000000148dcb0d 15. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88dc9 16. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 17. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 18. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 19. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 20. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 21. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 22. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 23. ? @ 0x00007fbc6213eac3 24. ? @ 0x00007fbc621d0850 2025.07.28 11:57:12.365890 [ 3285 ] {0755b4ed-e870-4c47-8b8d-6a61ac1fb0d7} executeQuery: Code: 524. DB::Exception: Trying to ALTER DROP column n3 which is referenced by materialized view ['01746_merge_tree_mv']. (ALTER_OF_COLUMN_IS_FORBIDDEN) (version 25.3.6.10636.altinitytest (altinity build)) (from [::1]:41286) (comment: 01746_forbid_drop_column_referenced_by_mv.sql) (query 5, line 21) (in query: ALTER TABLE `01746_merge_tree` DROP COLUMN n3;), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000a06a8eb 4. /build/src/Storages/MergeTree/MergeTreeData.cpp:3765: DB::MergeTreeData::checkAlterIsPossible(DB::AlterCommands const&, std::shared_ptr) const @ 0x00000000163387c2 5. /build/src/Interpreters/InterpreterAlterQuery.cpp:215: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x00000000148deab3 6. /build/src/Interpreters/InterpreterAlterQuery.cpp:77: DB::InterpreterAlterQuery::execute() @ 0x00000000148dcb0d 7. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88dc9 8. /build/src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x0000000014c8ca7b 9. /build/src/Interpreters/DDLWorker.cpp:510: DB::DDLWorker::tryExecuteQuery(DB::DDLTaskBase&, std::shared_ptr const&, bool) @ 0x00000000144dab9e 10. /build/src/Interpreters/DDLWorker.cpp:675: DB::DDLWorker::processTask(DB::DDLTaskBase&, std::shared_ptr const&, bool) @ 0x00000000144d8ffe 11. /build/src/Databases/DatabaseReplicatedWorker.cpp:372: DB::DatabaseReplicatedDDLWorker::tryEnqueueAndExecuteEntry(DB::DDLLogEntry&, std::shared_ptr, bool) @ 0x0000000013dc29ab 12. /build/src/Databases/DatabaseReplicated.cpp:1139: DB::DatabaseReplicated::tryEnqueueReplicatedDDL(std::shared_ptr const&, std::shared_ptr, DB::QueryFlags) @ 0x0000000013d9f73c 13. /build/src/Interpreters/InterpreterAlterQuery.cpp:130: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x00000000148dd805 14. /build/src/Interpreters/InterpreterAlterQuery.cpp:77: DB::InterpreterAlterQuery::execute() @ 0x00000000148dcb0d 15. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88dc9 16. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 17. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 18. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 19. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 20. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 21. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 22. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 23. ? @ 0x00007fbc6213eac3 24. ? @ 0x00007fbc621d0850 2025.07.28 11:57:12.372280 [ 3972 ] {} test_13.rmt2 (7f9b740d-015c-470e-8cc6-8ba33be0dc63): auto DB::StorageReplicatedMergeTree::processQueueEntry(ReplicatedMergeTreeQueue::SelectedEntryPtr)::(anonymous class)::operator()(LogEntryPtr &) const: Code: 86. DB::HTTPException: Received error from remote server http://146b4357c08d:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Ftest%2F01165%2Ftest_13%2Frmt%2Freplicas%2F1&part=20250728_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.6.10636.altinitytest (altinity build)) '. (RECEIVED_ERROR_FROM_REMOTE_IO_SERVER), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.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 const&, int&&, String const&, unsigned long&&, String const&) @ 0x000000000feda8d9 4. /build/src/IO/HTTPCommon.cpp:104: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x000000000feda6e2 5. /build/src/IO/HTTPCommon.cpp:93: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x000000000feda537 6. /build/src/IO/ReadWriteBufferFromHTTP.cpp:277: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x000000001184a4c4 7. /build/src/IO/ReadWriteBufferFromHTTP.cpp:285: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x000000001184a615 8. /build/src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x000000001184ae59 9. /build/src/IO/ReadWriteBufferFromHTTP.cpp:472: void std::__function::__policy_invoker::__call_impl[abi:se190107]>(std::__function::__policy_storage const*) @ 0x000000001184cedd 10. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001184858b 11. /build/src/IO/ReadWriteBufferFromHTTP.cpp:465: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x000000001184bf0b 12. /build/src/IO/ReadBuffer.h:60: DB::ReadBuffer::next() @ 0x000000000a148c7b 13. /build/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) @ 0x0000000011849fb2 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]>&)>&, 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&) @ 0x0000000011841980 15. /build/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) @ 0x000000001621208e 16. /build/src/Storages/StorageReplicatedMergeTree.cpp:5228: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl[abi:se190107] const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000015f9a5fe 17. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000015ed8bfd 18. /build/src/Storages/StorageReplicatedMergeTree.cpp:2514: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x0000000015ec9aab 19. /build/src/Storages/StorageReplicatedMergeTree.cpp:2349: DB::StorageReplicatedMergeTree::executeLogEntry(DB::ReplicatedMergeTreeLogEntry&) @ 0x0000000015eba91b 20. /build/src/Storages/StorageReplicatedMergeTree.cpp:3876: bool std::__function::__policy_invoker&)>::__call_impl[abi:se190107])::$_1, bool (std::shared_ptr&)>>(std::__function::__policy_storage const*, std::shared_ptr&) @ 0x0000000015f9837e 21. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000165d6fc3 22. /build/src/Storages/StorageReplicatedMergeTree.cpp:3872: DB::StorageReplicatedMergeTree::processQueueEntry(std::shared_ptr) @ 0x0000000015efc18a 23. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001624c1b2 24. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000162f9c70 25. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x00000000162fa55a 26. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc6653 27. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000000fccc4c3 28. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc3d92 29. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fcca080 30. ? @ 0x00007fbc6213eac3 31. ? @ 0x00007fbc621d0850 (version 25.3.6.10636.altinitytest (altinity build)) 2025.07.28 11:57:12.382711 [ 3285 ] {} TCPHandler: Code: 524. DB::Exception: Trying to ALTER DROP column n3 which is referenced by materialized view ['01746_merge_tree_mv']. (ALTER_OF_COLUMN_IS_FORBIDDEN), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000a06a8eb 4. /build/src/Storages/MergeTree/MergeTreeData.cpp:3765: DB::MergeTreeData::checkAlterIsPossible(DB::AlterCommands const&, std::shared_ptr) const @ 0x00000000163387c2 5. /build/src/Interpreters/InterpreterAlterQuery.cpp:215: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x00000000148deab3 6. /build/src/Interpreters/InterpreterAlterQuery.cpp:77: DB::InterpreterAlterQuery::execute() @ 0x00000000148dcb0d 7. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88dc9 8. /build/src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x0000000014c8ca7b 9. /build/src/Interpreters/DDLWorker.cpp:510: DB::DDLWorker::tryExecuteQuery(DB::DDLTaskBase&, std::shared_ptr const&, bool) @ 0x00000000144dab9e 10. /build/src/Interpreters/DDLWorker.cpp:675: DB::DDLWorker::processTask(DB::DDLTaskBase&, std::shared_ptr const&, bool) @ 0x00000000144d8ffe 11. /build/src/Databases/DatabaseReplicatedWorker.cpp:372: DB::DatabaseReplicatedDDLWorker::tryEnqueueAndExecuteEntry(DB::DDLLogEntry&, std::shared_ptr, bool) @ 0x0000000013dc29ab 12. /build/src/Databases/DatabaseReplicated.cpp:1139: DB::DatabaseReplicated::tryEnqueueReplicatedDDL(std::shared_ptr const&, std::shared_ptr, DB::QueryFlags) @ 0x0000000013d9f73c 13. /build/src/Interpreters/InterpreterAlterQuery.cpp:130: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x00000000148dd805 14. /build/src/Interpreters/InterpreterAlterQuery.cpp:77: DB::InterpreterAlterQuery::execute() @ 0x00000000148dcb0d 15. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88dc9 16. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 17. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 18. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 19. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 20. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 21. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 22. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 23. ? @ 0x00007fbc6213eac3 24. ? @ 0x00007fbc621d0850 2025.07.28 11:57:12.656637 [ 3285 ] {9cfe57b1-59f3-44dc-905f-f4d279af16d5} executeQuery: Code: 524. DB::Exception: Trying to ALTER DROP column n2 which is referenced by materialized view ['01746_merge_tree_mv']. (ALTER_OF_COLUMN_IS_FORBIDDEN) (version 25.3.6.10636.altinitytest (altinity build)) (from 0.0.0.0:0) (comment: 01746_forbid_drop_column_referenced_by_mv.sql) (in query: /* ddl_entry=query-0000000005 */ ALTER TABLE test_hz72qx47.`01746_merge_tree` (DROP COLUMN n2)), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000a06a8eb 4. /build/src/Storages/MergeTree/MergeTreeData.cpp:3765: DB::MergeTreeData::checkAlterIsPossible(DB::AlterCommands const&, std::shared_ptr) const @ 0x00000000163387c2 5. /build/src/Interpreters/InterpreterAlterQuery.cpp:215: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x00000000148deab3 6. /build/src/Interpreters/InterpreterAlterQuery.cpp:77: DB::InterpreterAlterQuery::execute() @ 0x00000000148dcb0d 7. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88dc9 8. /build/src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x0000000014c8ca7b 9. /build/src/Interpreters/DDLWorker.cpp:510: DB::DDLWorker::tryExecuteQuery(DB::DDLTaskBase&, std::shared_ptr const&, bool) @ 0x00000000144dab9e 10. /build/src/Interpreters/DDLWorker.cpp:675: DB::DDLWorker::processTask(DB::DDLTaskBase&, std::shared_ptr const&, bool) @ 0x00000000144d8ffe 11. /build/src/Databases/DatabaseReplicatedWorker.cpp:372: DB::DatabaseReplicatedDDLWorker::tryEnqueueAndExecuteEntry(DB::DDLLogEntry&, std::shared_ptr, bool) @ 0x0000000013dc29ab 12. /build/src/Databases/DatabaseReplicated.cpp:1139: DB::DatabaseReplicated::tryEnqueueReplicatedDDL(std::shared_ptr const&, std::shared_ptr, DB::QueryFlags) @ 0x0000000013d9f73c 13. /build/src/Interpreters/InterpreterAlterQuery.cpp:130: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x00000000148dd805 14. /build/src/Interpreters/InterpreterAlterQuery.cpp:77: DB::InterpreterAlterQuery::execute() @ 0x00000000148dcb0d 15. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88dc9 16. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 17. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 18. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 19. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 20. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 21. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 22. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 23. ? @ 0x00007fbc6213eac3 24. ? @ 0x00007fbc621d0850 2025.07.28 11:57:12.685083 [ 3285 ] {9cfe57b1-59f3-44dc-905f-f4d279af16d5} executeQuery: Code: 524. DB::Exception: Trying to ALTER DROP column n2 which is referenced by materialized view ['01746_merge_tree_mv']. (ALTER_OF_COLUMN_IS_FORBIDDEN) (version 25.3.6.10636.altinitytest (altinity build)) (from [::1]:41286) (comment: 01746_forbid_drop_column_referenced_by_mv.sql) (query 6, line 24) (in query: ALTER TABLE `01746_merge_tree` DROP COLUMN n2;), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000a06a8eb 4. /build/src/Storages/MergeTree/MergeTreeData.cpp:3765: DB::MergeTreeData::checkAlterIsPossible(DB::AlterCommands const&, std::shared_ptr) const @ 0x00000000163387c2 5. /build/src/Interpreters/InterpreterAlterQuery.cpp:215: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x00000000148deab3 6. /build/src/Interpreters/InterpreterAlterQuery.cpp:77: DB::InterpreterAlterQuery::execute() @ 0x00000000148dcb0d 7. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88dc9 8. /build/src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x0000000014c8ca7b 9. /build/src/Interpreters/DDLWorker.cpp:510: DB::DDLWorker::tryExecuteQuery(DB::DDLTaskBase&, std::shared_ptr const&, bool) @ 0x00000000144dab9e 10. /build/src/Interpreters/DDLWorker.cpp:675: DB::DDLWorker::processTask(DB::DDLTaskBase&, std::shared_ptr const&, bool) @ 0x00000000144d8ffe 11. /build/src/Databases/DatabaseReplicatedWorker.cpp:372: DB::DatabaseReplicatedDDLWorker::tryEnqueueAndExecuteEntry(DB::DDLLogEntry&, std::shared_ptr, bool) @ 0x0000000013dc29ab 12. /build/src/Databases/DatabaseReplicated.cpp:1139: DB::DatabaseReplicated::tryEnqueueReplicatedDDL(std::shared_ptr const&, std::shared_ptr, DB::QueryFlags) @ 0x0000000013d9f73c 13. /build/src/Interpreters/InterpreterAlterQuery.cpp:130: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x00000000148dd805 14. /build/src/Interpreters/InterpreterAlterQuery.cpp:77: DB::InterpreterAlterQuery::execute() @ 0x00000000148dcb0d 15. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88dc9 16. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 17. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 18. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 19. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 20. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 21. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 22. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 23. ? @ 0x00007fbc6213eac3 24. ? @ 0x00007fbc621d0850 2025.07.28 11:57:12.702640 [ 3285 ] {} TCPHandler: Code: 524. DB::Exception: Trying to ALTER DROP column n2 which is referenced by materialized view ['01746_merge_tree_mv']. (ALTER_OF_COLUMN_IS_FORBIDDEN), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000a06a8eb 4. /build/src/Storages/MergeTree/MergeTreeData.cpp:3765: DB::MergeTreeData::checkAlterIsPossible(DB::AlterCommands const&, std::shared_ptr) const @ 0x00000000163387c2 5. /build/src/Interpreters/InterpreterAlterQuery.cpp:215: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x00000000148deab3 6. /build/src/Interpreters/InterpreterAlterQuery.cpp:77: DB::InterpreterAlterQuery::execute() @ 0x00000000148dcb0d 7. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88dc9 8. /build/src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x0000000014c8ca7b 9. /build/src/Interpreters/DDLWorker.cpp:510: DB::DDLWorker::tryExecuteQuery(DB::DDLTaskBase&, std::shared_ptr const&, bool) @ 0x00000000144dab9e 10. /build/src/Interpreters/DDLWorker.cpp:675: DB::DDLWorker::processTask(DB::DDLTaskBase&, std::shared_ptr const&, bool) @ 0x00000000144d8ffe 11. /build/src/Databases/DatabaseReplicatedWorker.cpp:372: DB::DatabaseReplicatedDDLWorker::tryEnqueueAndExecuteEntry(DB::DDLLogEntry&, std::shared_ptr, bool) @ 0x0000000013dc29ab 12. /build/src/Databases/DatabaseReplicated.cpp:1139: DB::DatabaseReplicated::tryEnqueueReplicatedDDL(std::shared_ptr const&, std::shared_ptr, DB::QueryFlags) @ 0x0000000013d9f73c 13. /build/src/Interpreters/InterpreterAlterQuery.cpp:130: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x00000000148dd805 14. /build/src/Interpreters/InterpreterAlterQuery.cpp:77: DB::InterpreterAlterQuery::execute() @ 0x00000000148dcb0d 15. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88dc9 16. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 17. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 18. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 19. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 20. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 21. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 22. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 23. ? @ 0x00007fbc6213eac3 24. ? @ 0x00007fbc621d0850 2025.07.28 11:57:13.458149 [ 3976 ] {} test_13.rmt2 (7f9b740d-015c-470e-8cc6-8ba33be0dc63): auto DB::StorageReplicatedMergeTree::processQueueEntry(ReplicatedMergeTreeQueue::SelectedEntryPtr)::(anonymous class)::operator()(LogEntryPtr &) const: Code: 86. DB::HTTPException: Received error from remote server http://146b4357c08d:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Ftest%2F01165%2Ftest_13%2Frmt%2Freplicas%2F1&part=20250728_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.6.10636.altinitytest (altinity build)) '. (RECEIVED_ERROR_FROM_REMOTE_IO_SERVER), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.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 const&, int&&, String const&, unsigned long&&, String const&) @ 0x000000000feda8d9 4. /build/src/IO/HTTPCommon.cpp:104: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x000000000feda6e2 5. /build/src/IO/HTTPCommon.cpp:93: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x000000000feda537 6. /build/src/IO/ReadWriteBufferFromHTTP.cpp:277: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x000000001184a4c4 7. /build/src/IO/ReadWriteBufferFromHTTP.cpp:285: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x000000001184a615 8. /build/src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x000000001184ae59 9. /build/src/IO/ReadWriteBufferFromHTTP.cpp:472: void std::__function::__policy_invoker::__call_impl[abi:se190107]>(std::__function::__policy_storage const*) @ 0x000000001184cedd 10. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001184858b 11. /build/src/IO/ReadWriteBufferFromHTTP.cpp:465: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x000000001184bf0b 12. /build/src/IO/ReadBuffer.h:60: DB::ReadBuffer::next() @ 0x000000000a148c7b 13. /build/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) @ 0x0000000011849fb2 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]>&)>&, 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&) @ 0x0000000011841980 15. /build/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) @ 0x000000001621208e 16. /build/src/Storages/StorageReplicatedMergeTree.cpp:5228: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl[abi:se190107] const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000015f9a5fe 17. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000015ed8bfd 18. /build/src/Storages/StorageReplicatedMergeTree.cpp:2514: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x0000000015ec9aab 19. /build/src/Storages/StorageReplicatedMergeTree.cpp:2349: DB::StorageReplicatedMergeTree::executeLogEntry(DB::ReplicatedMergeTreeLogEntry&) @ 0x0000000015eba91b 20. /build/src/Storages/StorageReplicatedMergeTree.cpp:3876: bool std::__function::__policy_invoker&)>::__call_impl[abi:se190107])::$_1, bool (std::shared_ptr&)>>(std::__function::__policy_storage const*, std::shared_ptr&) @ 0x0000000015f9837e 21. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000165d6fc3 22. /build/src/Storages/StorageReplicatedMergeTree.cpp:3872: DB::StorageReplicatedMergeTree::processQueueEntry(std::shared_ptr) @ 0x0000000015efc18a 23. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001624c1b2 24. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000162f9c70 25. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x00000000162fa55a 26. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc6653 27. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000000fccc4c3 28. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc3d92 29. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fcca080 30. ? @ 0x00007fbc6213eac3 31. ? @ 0x00007fbc621d0850 (version 25.3.6.10636.altinitytest (altinity build)) 2025.07.28 11:57:13.804925 [ 3965 ] {} test_13.rmt2 (7f9b740d-015c-470e-8cc6-8ba33be0dc63): auto DB::StorageReplicatedMergeTree::processQueueEntry(ReplicatedMergeTreeQueue::SelectedEntryPtr)::(anonymous class)::operator()(LogEntryPtr &) const: Code: 86. DB::HTTPException: Received error from remote server http://146b4357c08d:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Ftest%2F01165%2Ftest_13%2Frmt%2Freplicas%2F1&part=20250728_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.6.10636.altinitytest (altinity build)) '. (RECEIVED_ERROR_FROM_REMOTE_IO_SERVER), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.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 const&, int&&, String const&, unsigned long&&, String const&) @ 0x000000000feda8d9 4. /build/src/IO/HTTPCommon.cpp:104: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x000000000feda6e2 5. /build/src/IO/HTTPCommon.cpp:93: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x000000000feda537 6. /build/src/IO/ReadWriteBufferFromHTTP.cpp:277: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x000000001184a4c4 7. /build/src/IO/ReadWriteBufferFromHTTP.cpp:285: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x000000001184a615 8. /build/src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x000000001184ae59 9. /build/src/IO/ReadWriteBufferFromHTTP.cpp:472: void std::__function::__policy_invoker::__call_impl[abi:se190107]>(std::__function::__policy_storage const*) @ 0x000000001184cedd 10. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001184858b 11. /build/src/IO/ReadWriteBufferFromHTTP.cpp:465: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x000000001184bf0b 12. /build/src/IO/ReadBuffer.h:60: DB::ReadBuffer::next() @ 0x000000000a148c7b 13. /build/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) @ 0x0000000011849fb2 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]>&)>&, 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&) @ 0x0000000011841980 15. /build/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) @ 0x000000001621208e 16. /build/src/Storages/StorageReplicatedMergeTree.cpp:5228: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl[abi:se190107] const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000015f9a5fe 17. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000015ed8bfd 18. /build/src/Storages/StorageReplicatedMergeTree.cpp:2514: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x0000000015ec9aab 19. /build/src/Storages/StorageReplicatedMergeTree.cpp:2349: DB::StorageReplicatedMergeTree::executeLogEntry(DB::ReplicatedMergeTreeLogEntry&) @ 0x0000000015eba91b 20. /build/src/Storages/StorageReplicatedMergeTree.cpp:3876: bool std::__function::__policy_invoker&)>::__call_impl[abi:se190107])::$_1, bool (std::shared_ptr&)>>(std::__function::__policy_storage const*, std::shared_ptr&) @ 0x0000000015f9837e 21. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000165d6fc3 22. /build/src/Storages/StorageReplicatedMergeTree.cpp:3872: DB::StorageReplicatedMergeTree::processQueueEntry(std::shared_ptr) @ 0x0000000015efc18a 23. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001624c1b2 24. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000162f9c70 25. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x00000000162fa55a 26. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc6653 27. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000000fccc4c3 28. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc3d92 29. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fcca080 30. ? @ 0x00007fbc6213eac3 31. ? @ 0x00007fbc621d0850 (version 25.3.6.10636.altinitytest (altinity build)) 2025.07.28 11:57:14.192385 [ 3961 ] {} test_13.rmt2 (7f9b740d-015c-470e-8cc6-8ba33be0dc63): auto DB::StorageReplicatedMergeTree::processQueueEntry(ReplicatedMergeTreeQueue::SelectedEntryPtr)::(anonymous class)::operator()(LogEntryPtr &) const: Code: 86. DB::HTTPException: Received error from remote server http://146b4357c08d:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Ftest%2F01165%2Ftest_13%2Frmt%2Freplicas%2F1&part=20250728_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.6.10636.altinitytest (altinity build)) '. (RECEIVED_ERROR_FROM_REMOTE_IO_SERVER), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.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 const&, int&&, String const&, unsigned long&&, String const&) @ 0x000000000feda8d9 4. /build/src/IO/HTTPCommon.cpp:104: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x000000000feda6e2 5. /build/src/IO/HTTPCommon.cpp:93: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x000000000feda537 6. /build/src/IO/ReadWriteBufferFromHTTP.cpp:277: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x000000001184a4c4 7. /build/src/IO/ReadWriteBufferFromHTTP.cpp:285: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x000000001184a615 8. /build/src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x000000001184ae59 9. /build/src/IO/ReadWriteBufferFromHTTP.cpp:472: void std::__function::__policy_invoker::__call_impl[abi:se190107]>(std::__function::__policy_storage const*) @ 0x000000001184cedd 10. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001184858b 11. /build/src/IO/ReadWriteBufferFromHTTP.cpp:465: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x000000001184bf0b 12. /build/src/IO/ReadBuffer.h:60: DB::ReadBuffer::next() @ 0x000000000a148c7b 13. /build/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) @ 0x0000000011849fb2 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]>&)>&, 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&) @ 0x0000000011841980 15. /build/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) @ 0x000000001621208e 16. /build/src/Storages/StorageReplicatedMergeTree.cpp:5228: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl[abi:se190107] const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000015f9a5fe 17. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000015ed8bfd 18. /build/src/Storages/StorageReplicatedMergeTree.cpp:2514: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x0000000015ec9aab 19. /build/src/Storages/StorageReplicatedMergeTree.cpp:2349: DB::StorageReplicatedMergeTree::executeLogEntry(DB::ReplicatedMergeTreeLogEntry&) @ 0x0000000015eba91b 20. /build/src/Storages/StorageReplicatedMergeTree.cpp:3876: bool std::__function::__policy_invoker&)>::__call_impl[abi:se190107])::$_1, bool (std::shared_ptr&)>>(std::__function::__policy_storage const*, std::shared_ptr&) @ 0x0000000015f9837e 21. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000165d6fc3 22. /build/src/Storages/StorageReplicatedMergeTree.cpp:3872: DB::StorageReplicatedMergeTree::processQueueEntry(std::shared_ptr) @ 0x0000000015efc18a 23. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001624c1b2 24. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000162f9c70 25. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x00000000162fa55a 26. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc6653 27. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000000fccc4c3 28. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc3d92 29. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fcca080 30. ? @ 0x00007fbc6213eac3 31. ? @ 0x00007fbc621d0850 (version 25.3.6.10636.altinitytest (altinity build)) 2025.07.28 11:57:14.476257 [ 17243 ] {} 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. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception>&, String>(int, FormatStringHelperImpl>&>::type, std::type_identity::type>, std::basic_string_view>&, String&&) @ 0x000000001385a5eb 4. /build/src/Access/SettingsConstraints.cpp:376: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000013859b18 5. /build/src/Access/SettingsConstraints.cpp:300: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000013858faf 6. /build/src/Access/SettingsConstraints.cpp:209: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000013859223 7. /build/src/Interpreters/Context.cpp:2690: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000014436134 8. /build/src/Interpreters/Context.cpp:2729: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x000000001443662b 9. /build/src/Server/HTTPHandler.cpp:457: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000001686d165 10. /build/src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x0000000016870807 11. /build/src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x0000000016907e99 12. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 13. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 14. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 15. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 16. ? @ 0x00007fbc6213eac3 17. ? @ 0x00007fbc621d0850 (version 25.3.6.10636.altinitytest (altinity build)) 2025.07.28 11:57:14.688397 [ 17287 ] {7bd97319-3f0a-45f6-aa8b-42ca2ce7ff63} executeQuery: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=28, jobs=1): (while reading prefix of column data.out.:`Array(JSON)`): (while reading from part /var/lib/clickhouse/store/b27/b27772a6-2882-4d9f-ac39-279aff7052ef/all_1_1_0/ in table test_15.t_json_6 (b27772a6-2882-4d9f-ac39-279aff7052ef) located on disk default of type local, from mark 0 with max_rows_to_read = 2): While executing MergeTreeSelect(pool: ReadPoolInOrder, algorithm: InOrder). (CANNOT_SCHEDULE_TASK) (version 25.3.6.10636.altinitytest (altinity build)) (from [::1]:41454) (comment: 01825_new_type_json_6.sh) (query 1, line 1) (in query: SELECT DISTINCT arrayJoin(JSONAllPathsWithTypes(arrayJoin(data.out[]))) as path FROM t_json_6 order by path;), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000fccaeeb 4. /build/src/Common/ThreadPool.cpp:275: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000fccc813 5. /build/src/Common/ThreadPool.cpp:323: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fcc7bbc 6. /build/src/Common/ThreadPool.cpp:494: ThreadPoolImpl>::scheduleOrThrowOnError(std::function, Priority) @ 0x000000000fcc7a0e 7. /build/src/Common/threadPoolCallbackRunner.h:52: std::future> std::__function::__policy_invoker> (DB::MergeTreeMarksLoader::loadMarksAsync()::$_0&&, Priority)>::__call_impl[abi:se190107]> (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&&) @ 0x0000000016474731 8. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000016471940 9. /build/src/Storages/MergeTree/MergeTreeMarksLoader.cpp:83: DB::MergeTreeMarksLoader::startAsyncLoad() @ 0x000000001647173f 10. /build/src/Storages/MergeTree/MergeTreeReaderWide.cpp:294: DB::MergeTreeReaderWide::addStream(DB::ISerialization::SubstreamPath const&, String const&) @ 0x00000000164aa163 11. /build/src/Storages/MergeTree/MergeTreeReaderWide.cpp:376: void std::__function::__policy_invoker::__call_impl[abi:se190107] 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&) @ 0x00000000164ab79d 12. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000013cf3e04 13. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000013cf3e04 14. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000013c7aa09 15. /build/src/DataTypes/Serializations/SerializationVariant.cpp:101: DB::SerializationVariant::enumerateStreams(DB::ISerialization::EnumerateStreamsSettings&, std::function const&, DB::ISerialization::SubstreamData const&) const @ 0x0000000013d2c5e5 16. /build/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 @ 0x0000000013c99d73 17. /build/src/DataTypes/Serializations/SerializationObject.cpp:445: void std::__function::__policy_invoker::__call_impl[abi:se190107]&, std::unordered_map, std::hash, std::equal_to, std::allocator>>>*) const::$_4, void ()>>(std::__function::__policy_storage const*) @ 0x0000000013cf3c2e 18. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000013cea1a0 19. /build/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 @ 0x0000000013c83d45 20. /build/src/DataTypes/Serializations/SerializationVariant.cpp:193: DB::SerializationVariant::deserializeBinaryBulkStatePrefix(DB::ISerialization::DeserializeBinaryBulkSettings&, std::shared_ptr&, std::unordered_map, std::hash, std::equal_to, std::allocator>>>*) const @ 0x0000000013d2eaf1 21. /build/src/DataTypes/Serializations/SerializationDynamic.cpp:250: DB::SerializationDynamic::deserializeBinaryBulkStatePrefix(DB::ISerialization::DeserializeBinaryBulkSettings&, std::shared_ptr&, std::unordered_map, std::hash, std::equal_to, std::allocator>>>*) const @ 0x0000000013c99e2c 22. /build/src/DataTypes/Serializations/SerializationObject.cpp:445: void std::__function::__policy_invoker::__call_impl[abi:se190107]&, std::unordered_map, std::hash, std::equal_to, std::allocator>>>*) const::$_4, void ()>>(std::__function::__policy_storage const*) @ 0x0000000013cf3c2e 23. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000013cf3fc4 24. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc6653 25. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000000fccc4c3 26. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc3d92 27. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fcca080 28. ? @ 0x00007fbc6213eac3 29. ? @ 0x00007fbc621d0850 2025.07.28 11:57:14.756232 [ 3967 ] {} test_13.rmt2 (7f9b740d-015c-470e-8cc6-8ba33be0dc63): auto DB::StorageReplicatedMergeTree::processQueueEntry(ReplicatedMergeTreeQueue::SelectedEntryPtr)::(anonymous class)::operator()(LogEntryPtr &) const: Code: 86. DB::HTTPException: Received error from remote server http://146b4357c08d:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Ftest%2F01165%2Ftest_13%2Frmt%2Freplicas%2F1&part=20250728_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.6.10636.altinitytest (altinity build)) '. (RECEIVED_ERROR_FROM_REMOTE_IO_SERVER), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.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 const&, int&&, String const&, unsigned long&&, String const&) @ 0x000000000feda8d9 4. /build/src/IO/HTTPCommon.cpp:104: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x000000000feda6e2 5. /build/src/IO/HTTPCommon.cpp:93: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x000000000feda537 6. /build/src/IO/ReadWriteBufferFromHTTP.cpp:277: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x000000001184a4c4 7. /build/src/IO/ReadWriteBufferFromHTTP.cpp:285: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x000000001184a615 8. /build/src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x000000001184ae59 9. /build/src/IO/ReadWriteBufferFromHTTP.cpp:472: void std::__function::__policy_invoker::__call_impl[abi:se190107]>(std::__function::__policy_storage const*) @ 0x000000001184cedd 10. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001184858b 11. /build/src/IO/ReadWriteBufferFromHTTP.cpp:465: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x000000001184bf0b 12. /build/src/IO/ReadBuffer.h:60: DB::ReadBuffer::next() @ 0x000000000a148c7b 13. /build/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) @ 0x0000000011849fb2 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]>&)>&, 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&) @ 0x0000000011841980 15. /build/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) @ 0x000000001621208e 16. /build/src/Storages/StorageReplicatedMergeTree.cpp:5228: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl[abi:se190107] const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000015f9a5fe 17. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000015ed8bfd 18. /build/src/Storages/StorageReplicatedMergeTree.cpp:2514: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x0000000015ec9aab 19. /build/src/Storages/StorageReplicatedMergeTree.cpp:2349: DB::StorageReplicatedMergeTree::executeLogEntry(DB::ReplicatedMergeTreeLogEntry&) @ 0x0000000015eba91b 20. /build/src/Storages/StorageReplicatedMergeTree.cpp:3876: bool std::__function::__policy_invoker&)>::__call_impl[abi:se190107])::$_1, bool (std::shared_ptr&)>>(std::__function::__policy_storage const*, std::shared_ptr&) @ 0x0000000015f9837e 21. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000165d6fc3 22. /build/src/Storages/StorageReplicatedMergeTree.cpp:3872: DB::StorageReplicatedMergeTree::processQueueEntry(std::shared_ptr) @ 0x0000000015efc18a 23. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001624c1b2 24. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000162f9c70 25. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x00000000162fa55a 26. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc6653 27. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000000fccc4c3 28. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc3d92 29. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fcca080 30. ? @ 0x00007fbc6213eac3 31. ? @ 0x00007fbc621d0850 (version 25.3.6.10636.altinitytest (altinity build)) 2025.07.28 11:57:14.889873 [ 3285 ] {5b1e6e96-833e-42ac-b872-ea00a4c4e453} executeQuery: Code: 524. DB::Exception: Trying to ALTER DROP column n1 which is referenced by materialized view ['01746_null_mv']. (ALTER_OF_COLUMN_IS_FORBIDDEN) (version 25.3.6.10636.altinitytest (altinity build)) (from 0.0.0.0:0) (comment: 01746_forbid_drop_column_referenced_by_mv.sql) (in query: /* ddl_entry=query-0000000011 */ ALTER TABLE test_hz72qx47.`01746_null` (DROP COLUMN n1)), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000a06a8eb 4. /build/src/Storages/StorageNull.cpp:59: DB::StorageNull::checkAlterIsPossible(DB::AlterCommands const&, std::shared_ptr) const @ 0x0000000015e70b90 5. /build/src/Interpreters/InterpreterAlterQuery.cpp:215: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x00000000148deab3 6. /build/src/Interpreters/InterpreterAlterQuery.cpp:77: DB::InterpreterAlterQuery::execute() @ 0x00000000148dcb0d 7. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88dc9 8. /build/src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x0000000014c8ca7b 9. /build/src/Interpreters/DDLWorker.cpp:510: DB::DDLWorker::tryExecuteQuery(DB::DDLTaskBase&, std::shared_ptr const&, bool) @ 0x00000000144dab9e 10. /build/src/Interpreters/DDLWorker.cpp:675: DB::DDLWorker::processTask(DB::DDLTaskBase&, std::shared_ptr const&, bool) @ 0x00000000144d8ffe 11. /build/src/Databases/DatabaseReplicatedWorker.cpp:372: DB::DatabaseReplicatedDDLWorker::tryEnqueueAndExecuteEntry(DB::DDLLogEntry&, std::shared_ptr, bool) @ 0x0000000013dc29ab 12. /build/src/Databases/DatabaseReplicated.cpp:1139: DB::DatabaseReplicated::tryEnqueueReplicatedDDL(std::shared_ptr const&, std::shared_ptr, DB::QueryFlags) @ 0x0000000013d9f73c 13. /build/src/Interpreters/InterpreterAlterQuery.cpp:130: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x00000000148dd805 14. /build/src/Interpreters/InterpreterAlterQuery.cpp:77: DB::InterpreterAlterQuery::execute() @ 0x00000000148dcb0d 15. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88dc9 16. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 17. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 18. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 19. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 20. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 21. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 22. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 23. ? @ 0x00007fbc6213eac3 24. ? @ 0x00007fbc621d0850 2025.07.28 11:57:14.957982 [ 17287 ] {} TCPHandler: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=28, jobs=1): (while reading prefix of column data.out.:`Array(JSON)`): (while reading from part /var/lib/clickhouse/store/b27/b27772a6-2882-4d9f-ac39-279aff7052ef/all_1_1_0/ in table test_15.t_json_6 (b27772a6-2882-4d9f-ac39-279aff7052ef) located on disk default of type local, from mark 0 with max_rows_to_read = 2): While executing MergeTreeSelect(pool: ReadPoolInOrder, algorithm: InOrder). (CANNOT_SCHEDULE_TASK), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000fccaeeb 4. /build/src/Common/ThreadPool.cpp:275: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000fccc813 5. /build/src/Common/ThreadPool.cpp:323: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fcc7bbc 6. /build/src/Common/ThreadPool.cpp:494: ThreadPoolImpl>::scheduleOrThrowOnError(std::function, Priority) @ 0x000000000fcc7a0e 7. /build/src/Common/threadPoolCallbackRunner.h:52: std::future> std::__function::__policy_invoker> (DB::MergeTreeMarksLoader::loadMarksAsync()::$_0&&, Priority)>::__call_impl[abi:se190107]> (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&&) @ 0x0000000016474731 8. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000016471940 9. /build/src/Storages/MergeTree/MergeTreeMarksLoader.cpp:83: DB::MergeTreeMarksLoader::startAsyncLoad() @ 0x000000001647173f 10. /build/src/Storages/MergeTree/MergeTreeReaderWide.cpp:294: DB::MergeTreeReaderWide::addStream(DB::ISerialization::SubstreamPath const&, String const&) @ 0x00000000164aa163 11. /build/src/Storages/MergeTree/MergeTreeReaderWide.cpp:376: void std::__function::__policy_invoker::__call_impl[abi:se190107] 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&) @ 0x00000000164ab79d 12. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000013cf3e04 13. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000013cf3e04 14. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000013c7aa09 15. /build/src/DataTypes/Serializations/SerializationVariant.cpp:101: DB::SerializationVariant::enumerateStreams(DB::ISerialization::EnumerateStreamsSettings&, std::function const&, DB::ISerialization::SubstreamData const&) const @ 0x0000000013d2c5e5 16. /build/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 @ 0x0000000013c99d73 17. /build/src/DataTypes/Serializations/SerializationObject.cpp:445: void std::__function::__policy_invoker::__call_impl[abi:se190107]&, std::unordered_map, std::hash, std::equal_to, std::allocator>>>*) const::$_4, void ()>>(std::__function::__policy_storage const*) @ 0x0000000013cf3c2e 18. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000013cea1a0 19. /build/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 @ 0x0000000013c83d45 20. /build/src/DataTypes/Serializations/SerializationVariant.cpp:193: DB::SerializationVariant::deserializeBinaryBulkStatePrefix(DB::ISerialization::DeserializeBinaryBulkSettings&, std::shared_ptr&, std::unordered_map, std::hash, std::equal_to, std::allocator>>>*) const @ 0x0000000013d2eaf1 21. /build/src/DataTypes/Serializations/SerializationDynamic.cpp:250: DB::SerializationDynamic::deserializeBinaryBulkStatePrefix(DB::ISerialization::DeserializeBinaryBulkSettings&, std::shared_ptr&, std::unordered_map, std::hash, std::equal_to, std::allocator>>>*) const @ 0x0000000013c99e2c 22. /build/src/DataTypes/Serializations/SerializationObject.cpp:445: void std::__function::__policy_invoker::__call_impl[abi:se190107]&, std::unordered_map, std::hash, std::equal_to, std::allocator>>>*) const::$_4, void ()>>(std::__function::__policy_storage const*) @ 0x0000000013cf3c2e 23. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000013cf3fc4 24. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc6653 25. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000000fccc4c3 26. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc3d92 27. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fcca080 28. ? @ 0x00007fbc6213eac3 29. ? @ 0x00007fbc621d0850 Job's origin stack trace: 0. /build/src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000000fc33b84 1. /build/src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000000fcc2ea7 2. /build/src/Common/ThreadPool.cpp:401: bool ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fcc88e9 3. /build/src/Common/ThreadPool.cpp:500: ThreadPoolImpl>::trySchedule(std::function, Priority, unsigned long) @ 0x000000000fcc840f 4. /build/src/DataTypes/Serializations/SerializationObject.cpp:451: DB::SerializationObject::deserializeBinaryBulkStatePrefix(DB::ISerialization::DeserializeBinaryBulkSettings&, std::shared_ptr&, std::unordered_map, std::hash, std::equal_to, std::allocator>>>*) const @ 0x0000000013ce9fed 5. /build/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 @ 0x0000000013c83d45 6. /build/src/DataTypes/Serializations/SerializationVariantElement.cpp:86: DB::SerializationVariantElement::deserializeBinaryBulkStatePrefix(DB::ISerialization::DeserializeBinaryBulkSettings&, std::shared_ptr&, std::unordered_map, std::hash, std::equal_to, std::allocator>>>*) const @ 0x0000000013d3ca47 7. /build/src/DataTypes/Serializations/SerializationDynamicElement.cpp:101: DB::SerializationDynamicElement::deserializeBinaryBulkStatePrefix(DB::ISerialization::DeserializeBinaryBulkSettings&, std::shared_ptr&, std::unordered_map, std::hash, std::equal_to, std::allocator>>>*) const @ 0x0000000013ca7535 8. /build/src/DataTypes/Serializations/SerializationObjectDynamicPath.cpp:124: DB::SerializationObjectDynamicPath::deserializeBinaryBulkStatePrefix(DB::ISerialization::DeserializeBinaryBulkSettings&, std::shared_ptr&, std::unordered_map, std::hash, std::equal_to, std::allocator>>>*) const @ 0x0000000013d0c4a9 9. /build/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) @ 0x00000000164aa967 10. /build/src/Storages/MergeTree/MergeTreeReaderWide.cpp:397: DB::MergeTreeReaderWide::deserializePrefixForAllColumnsImpl(unsigned long, unsigned long, unsigned long, std::function (DB::NameAndTypePair const&)>)::$_0::operator()() const @ 0x00000000164aafe2 11. /build/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:se190107] (DB::NameAndTypePair const&)>)::$_0, std::unordered_map, std::hash, std::equal_to, std::allocator>>> ()>>(std::__function::__policy_storage const*) @ 0x00000000164ab84c 12. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000164ad047 13. /build/src/Storages/MergeTree/MergeTreeReaderWide.cpp:420: DB::MergeTreeReaderWide::deserializePrefixForAllColumnsImpl(unsigned long, unsigned long, unsigned long, std::function (DB::NameAndTypePair const&)>) @ 0x00000000164aab4e 14. /build/src/Storages/MergeTree/MergeTreeReaderWide.cpp:427: DB::MergeTreeReaderWide::readRows(unsigned long, unsigned long, bool, unsigned long, std::vector::immutable_ptr, std::allocator::immutable_ptr>>&) @ 0x00000000164a920e 15. /build/src/Storages/MergeTree/MergeTreeRangeReader.cpp:116: DB::MergeTreeRangeReader::DelayedStream::finalize(std::vector::immutable_ptr, std::allocator::immutable_ptr>>&) @ 0x0000000016497db1 16. /build/src/Storages/MergeTree/MergeTreeRangeReader.cpp:298: DB::MergeTreeRangeReader::startReadingChain(unsigned long, DB::MarkRanges&) @ 0x000000001649f129 17. /build/src/Storages/MergeTree/MergeTreeReadersChain.cpp:67: DB::MergeTreeReadersChain::read(unsigned long, DB::MarkRanges&) @ 0x00000000164b9dda 18. /build/src/Storages/MergeTree/MergeTreeReadTask.cpp:172: DB::MergeTreeReadTask::read() @ 0x00000000164b6300 19. /build/src/Storages/MergeTree/MergeTreeSelectAlgorithms.h:53: DB::MergeTreeInOrderSelectAlgorithm::readFromTask(DB::MergeTreeReadTask&) @ 0x0000000016e56d4c 20. /build/src/Storages/MergeTree/MergeTreeSelectProcessor.cpp:207: DB::MergeTreeSelectProcessor::read() @ 0x00000000164c0ba4 21. /build/src/Storages/MergeTree/MergeTreeSource.cpp:229: DB::MergeTreeSource::tryGenerate() @ 0x0000000016e43d69 22. /build/src/Processors/ISource.cpp:108: DB::ISource::work() @ 0x00000000169a21e7 23. /build/src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x00000000169bd00f 24. /build/src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x00000000169b2105 25. /build/src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeSingleThread(unsigned long) @ 0x00000000169b23be 26. /build/src/Processors/Executors/PipelineExecutor.cpp:454: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x00000000169b0be7 27. /build/src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x00000000169b03f4 28. /build/src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:se190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169bfeab 29. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc3d92 30. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fcca080 31. ? @ 0x00007fbc6213eac3 32. ? @ 0x00007fbc621d0850 Job's origin stack trace: 0. /build/src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000000fc33b84 1. /build/src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000000fcc2ea7 2. /build/src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fcc535c 3. /build/src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000000fcc584d 4. /build/src/Common/ThreadPool.h:279: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x00000000169bf193 5. /build/src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x00000000169bf518 6. /build/src/Server/TCPHandler.cpp:1237: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x00000000168f1525 7. /build/src/Server/TCPHandler.cpp:678: DB::TCPHandler::runImpl() @ 0x00000000168e68e5 8. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 9. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 10. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 11. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 12. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 13. ? @ 0x00007fbc6213eac3 14. ? @ 0x00007fbc621d0850 2025.07.28 11:57:14.977632 [ 3285 ] {5b1e6e96-833e-42ac-b872-ea00a4c4e453} executeQuery: Code: 524. DB::Exception: Trying to ALTER DROP column n1 which is referenced by materialized view ['01746_null_mv']. (ALTER_OF_COLUMN_IS_FORBIDDEN) (version 25.3.6.10636.altinitytest (altinity build)) (from [::1]:41286) (comment: 01746_forbid_drop_column_referenced_by_mv.sql) (query 14, line 52) (in query: ALTER TABLE `01746_null` DROP COLUMN n1;), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000a06a8eb 4. /build/src/Storages/StorageNull.cpp:59: DB::StorageNull::checkAlterIsPossible(DB::AlterCommands const&, std::shared_ptr) const @ 0x0000000015e70b90 5. /build/src/Interpreters/InterpreterAlterQuery.cpp:215: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x00000000148deab3 6. /build/src/Interpreters/InterpreterAlterQuery.cpp:77: DB::InterpreterAlterQuery::execute() @ 0x00000000148dcb0d 7. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88dc9 8. /build/src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x0000000014c8ca7b 9. /build/src/Interpreters/DDLWorker.cpp:510: DB::DDLWorker::tryExecuteQuery(DB::DDLTaskBase&, std::shared_ptr const&, bool) @ 0x00000000144dab9e 10. /build/src/Interpreters/DDLWorker.cpp:675: DB::DDLWorker::processTask(DB::DDLTaskBase&, std::shared_ptr const&, bool) @ 0x00000000144d8ffe 11. /build/src/Databases/DatabaseReplicatedWorker.cpp:372: DB::DatabaseReplicatedDDLWorker::tryEnqueueAndExecuteEntry(DB::DDLLogEntry&, std::shared_ptr, bool) @ 0x0000000013dc29ab 12. /build/src/Databases/DatabaseReplicated.cpp:1139: DB::DatabaseReplicated::tryEnqueueReplicatedDDL(std::shared_ptr const&, std::shared_ptr, DB::QueryFlags) @ 0x0000000013d9f73c 13. /build/src/Interpreters/InterpreterAlterQuery.cpp:130: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x00000000148dd805 14. /build/src/Interpreters/InterpreterAlterQuery.cpp:77: DB::InterpreterAlterQuery::execute() @ 0x00000000148dcb0d 15. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88dc9 16. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 17. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 18. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 19. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 20. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 21. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 22. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 23. ? @ 0x00007fbc6213eac3 24. ? @ 0x00007fbc621d0850 2025.07.28 11:57:15.003408 [ 3285 ] {} TCPHandler: Code: 524. DB::Exception: Trying to ALTER DROP column n1 which is referenced by materialized view ['01746_null_mv']. (ALTER_OF_COLUMN_IS_FORBIDDEN), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000a06a8eb 4. /build/src/Storages/StorageNull.cpp:59: DB::StorageNull::checkAlterIsPossible(DB::AlterCommands const&, std::shared_ptr) const @ 0x0000000015e70b90 5. /build/src/Interpreters/InterpreterAlterQuery.cpp:215: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x00000000148deab3 6. /build/src/Interpreters/InterpreterAlterQuery.cpp:77: DB::InterpreterAlterQuery::execute() @ 0x00000000148dcb0d 7. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88dc9 8. /build/src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x0000000014c8ca7b 9. /build/src/Interpreters/DDLWorker.cpp:510: DB::DDLWorker::tryExecuteQuery(DB::DDLTaskBase&, std::shared_ptr const&, bool) @ 0x00000000144dab9e 10. /build/src/Interpreters/DDLWorker.cpp:675: DB::DDLWorker::processTask(DB::DDLTaskBase&, std::shared_ptr const&, bool) @ 0x00000000144d8ffe 11. /build/src/Databases/DatabaseReplicatedWorker.cpp:372: DB::DatabaseReplicatedDDLWorker::tryEnqueueAndExecuteEntry(DB::DDLLogEntry&, std::shared_ptr, bool) @ 0x0000000013dc29ab 12. /build/src/Databases/DatabaseReplicated.cpp:1139: DB::DatabaseReplicated::tryEnqueueReplicatedDDL(std::shared_ptr const&, std::shared_ptr, DB::QueryFlags) @ 0x0000000013d9f73c 13. /build/src/Interpreters/InterpreterAlterQuery.cpp:130: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x00000000148dd805 14. /build/src/Interpreters/InterpreterAlterQuery.cpp:77: DB::InterpreterAlterQuery::execute() @ 0x00000000148dcb0d 15. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88dc9 16. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 17. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 18. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 19. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 20. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 21. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 22. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 23. ? @ 0x00007fbc6213eac3 24. ? @ 0x00007fbc621d0850 2025.07.28 11:57:15.298660 [ 3960 ] {} test_13.rmt2 (7f9b740d-015c-470e-8cc6-8ba33be0dc63): auto DB::StorageReplicatedMergeTree::processQueueEntry(ReplicatedMergeTreeQueue::SelectedEntryPtr)::(anonymous class)::operator()(LogEntryPtr &) const: Code: 86. DB::HTTPException: Received error from remote server http://146b4357c08d:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Ftest%2F01165%2Ftest_13%2Frmt%2Freplicas%2F1&part=20250728_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.6.10636.altinitytest (altinity build)) '. (RECEIVED_ERROR_FROM_REMOTE_IO_SERVER), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.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 const&, int&&, String const&, unsigned long&&, String const&) @ 0x000000000feda8d9 4. /build/src/IO/HTTPCommon.cpp:104: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x000000000feda6e2 5. /build/src/IO/HTTPCommon.cpp:93: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x000000000feda537 6. /build/src/IO/ReadWriteBufferFromHTTP.cpp:277: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x000000001184a4c4 7. /build/src/IO/ReadWriteBufferFromHTTP.cpp:285: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x000000001184a615 8. /build/src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x000000001184ae59 9. /build/src/IO/ReadWriteBufferFromHTTP.cpp:472: void std::__function::__policy_invoker::__call_impl[abi:se190107]>(std::__function::__policy_storage const*) @ 0x000000001184cedd 10. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001184858b 11. /build/src/IO/ReadWriteBufferFromHTTP.cpp:465: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x000000001184bf0b 12. /build/src/IO/ReadBuffer.h:60: DB::ReadBuffer::next() @ 0x000000000a148c7b 13. /build/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) @ 0x0000000011849fb2 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]>&)>&, 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&) @ 0x0000000011841980 15. /build/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) @ 0x000000001621208e 16. /build/src/Storages/StorageReplicatedMergeTree.cpp:5228: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl[abi:se190107] const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000015f9a5fe 17. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000015ed8bfd 18. /build/src/Storages/StorageReplicatedMergeTree.cpp:2514: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x0000000015ec9aab 19. /build/src/Storages/StorageReplicatedMergeTree.cpp:2349: DB::StorageReplicatedMergeTree::executeLogEntry(DB::ReplicatedMergeTreeLogEntry&) @ 0x0000000015eba91b 20. /build/src/Storages/StorageReplicatedMergeTree.cpp:3876: bool std::__function::__policy_invoker&)>::__call_impl[abi:se190107])::$_1, bool (std::shared_ptr&)>>(std::__function::__policy_storage const*, std::shared_ptr&) @ 0x0000000015f9837e 21. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000165d6fc3 22. /build/src/Storages/StorageReplicatedMergeTree.cpp:3872: DB::StorageReplicatedMergeTree::processQueueEntry(std::shared_ptr) @ 0x0000000015efc18a 23. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001624c1b2 24. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000162f9c70 25. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x00000000162fa55a 26. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc6653 27. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000000fccc4c3 28. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc3d92 29. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fcca080 30. ? @ 0x00007fbc6213eac3 31. ? @ 0x00007fbc621d0850 (version 25.3.6.10636.altinitytest (altinity build)) 2025.07.28 11:57:15.326959 [ 3285 ] {8ff66095-2a02-4b54-9a39-d331f610c522} executeQuery: Code: 524. DB::Exception: Trying to ALTER DROP column n2 which is referenced by materialized view ['01746_null_mv']. (ALTER_OF_COLUMN_IS_FORBIDDEN) (version 25.3.6.10636.altinitytest (altinity build)) (from 0.0.0.0:0) (comment: 01746_forbid_drop_column_referenced_by_mv.sql) (in query: /* ddl_entry=query-0000000012 */ ALTER TABLE test_hz72qx47.`01746_null` (DROP COLUMN n2)), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000a06a8eb 4. /build/src/Storages/StorageNull.cpp:59: DB::StorageNull::checkAlterIsPossible(DB::AlterCommands const&, std::shared_ptr) const @ 0x0000000015e70b90 5. /build/src/Interpreters/InterpreterAlterQuery.cpp:215: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x00000000148deab3 6. /build/src/Interpreters/InterpreterAlterQuery.cpp:77: DB::InterpreterAlterQuery::execute() @ 0x00000000148dcb0d 7. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88dc9 8. /build/src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x0000000014c8ca7b 9. /build/src/Interpreters/DDLWorker.cpp:510: DB::DDLWorker::tryExecuteQuery(DB::DDLTaskBase&, std::shared_ptr const&, bool) @ 0x00000000144dab9e 10. /build/src/Interpreters/DDLWorker.cpp:675: DB::DDLWorker::processTask(DB::DDLTaskBase&, std::shared_ptr const&, bool) @ 0x00000000144d8ffe 11. /build/src/Databases/DatabaseReplicatedWorker.cpp:372: DB::DatabaseReplicatedDDLWorker::tryEnqueueAndExecuteEntry(DB::DDLLogEntry&, std::shared_ptr, bool) @ 0x0000000013dc29ab 12. /build/src/Databases/DatabaseReplicated.cpp:1139: DB::DatabaseReplicated::tryEnqueueReplicatedDDL(std::shared_ptr const&, std::shared_ptr, DB::QueryFlags) @ 0x0000000013d9f73c 13. /build/src/Interpreters/InterpreterAlterQuery.cpp:130: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x00000000148dd805 14. /build/src/Interpreters/InterpreterAlterQuery.cpp:77: DB::InterpreterAlterQuery::execute() @ 0x00000000148dcb0d 15. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88dc9 16. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 17. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 18. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 19. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 20. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 21. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 22. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 23. ? @ 0x00007fbc6213eac3 24. ? @ 0x00007fbc621d0850 2025.07.28 11:57:15.348863 [ 3285 ] {8ff66095-2a02-4b54-9a39-d331f610c522} executeQuery: Code: 524. DB::Exception: Trying to ALTER DROP column n2 which is referenced by materialized view ['01746_null_mv']. (ALTER_OF_COLUMN_IS_FORBIDDEN) (version 25.3.6.10636.altinitytest (altinity build)) (from [::1]:41286) (comment: 01746_forbid_drop_column_referenced_by_mv.sql) (query 15, line 55) (in query: ALTER TABLE `01746_null` DROP COLUMN n2;), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000a06a8eb 4. /build/src/Storages/StorageNull.cpp:59: DB::StorageNull::checkAlterIsPossible(DB::AlterCommands const&, std::shared_ptr) const @ 0x0000000015e70b90 5. /build/src/Interpreters/InterpreterAlterQuery.cpp:215: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x00000000148deab3 6. /build/src/Interpreters/InterpreterAlterQuery.cpp:77: DB::InterpreterAlterQuery::execute() @ 0x00000000148dcb0d 7. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88dc9 8. /build/src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x0000000014c8ca7b 9. /build/src/Interpreters/DDLWorker.cpp:510: DB::DDLWorker::tryExecuteQuery(DB::DDLTaskBase&, std::shared_ptr const&, bool) @ 0x00000000144dab9e 10. /build/src/Interpreters/DDLWorker.cpp:675: DB::DDLWorker::processTask(DB::DDLTaskBase&, std::shared_ptr const&, bool) @ 0x00000000144d8ffe 11. /build/src/Databases/DatabaseReplicatedWorker.cpp:372: DB::DatabaseReplicatedDDLWorker::tryEnqueueAndExecuteEntry(DB::DDLLogEntry&, std::shared_ptr, bool) @ 0x0000000013dc29ab 12. /build/src/Databases/DatabaseReplicated.cpp:1139: DB::DatabaseReplicated::tryEnqueueReplicatedDDL(std::shared_ptr const&, std::shared_ptr, DB::QueryFlags) @ 0x0000000013d9f73c 13. /build/src/Interpreters/InterpreterAlterQuery.cpp:130: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x00000000148dd805 14. /build/src/Interpreters/InterpreterAlterQuery.cpp:77: DB::InterpreterAlterQuery::execute() @ 0x00000000148dcb0d 15. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88dc9 16. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 17. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 18. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 19. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 20. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 21. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 22. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 23. ? @ 0x00007fbc6213eac3 24. ? @ 0x00007fbc621d0850 2025.07.28 11:57:15.351691 [ 3285 ] {} TCPHandler: Code: 524. DB::Exception: Trying to ALTER DROP column n2 which is referenced by materialized view ['01746_null_mv']. (ALTER_OF_COLUMN_IS_FORBIDDEN), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000a06a8eb 4. /build/src/Storages/StorageNull.cpp:59: DB::StorageNull::checkAlterIsPossible(DB::AlterCommands const&, std::shared_ptr) const @ 0x0000000015e70b90 5. /build/src/Interpreters/InterpreterAlterQuery.cpp:215: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x00000000148deab3 6. /build/src/Interpreters/InterpreterAlterQuery.cpp:77: DB::InterpreterAlterQuery::execute() @ 0x00000000148dcb0d 7. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88dc9 8. /build/src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x0000000014c8ca7b 9. /build/src/Interpreters/DDLWorker.cpp:510: DB::DDLWorker::tryExecuteQuery(DB::DDLTaskBase&, std::shared_ptr const&, bool) @ 0x00000000144dab9e 10. /build/src/Interpreters/DDLWorker.cpp:675: DB::DDLWorker::processTask(DB::DDLTaskBase&, std::shared_ptr const&, bool) @ 0x00000000144d8ffe 11. /build/src/Databases/DatabaseReplicatedWorker.cpp:372: DB::DatabaseReplicatedDDLWorker::tryEnqueueAndExecuteEntry(DB::DDLLogEntry&, std::shared_ptr, bool) @ 0x0000000013dc29ab 12. /build/src/Databases/DatabaseReplicated.cpp:1139: DB::DatabaseReplicated::tryEnqueueReplicatedDDL(std::shared_ptr const&, std::shared_ptr, DB::QueryFlags) @ 0x0000000013d9f73c 13. /build/src/Interpreters/InterpreterAlterQuery.cpp:130: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x00000000148dd805 14. /build/src/Interpreters/InterpreterAlterQuery.cpp:77: DB::InterpreterAlterQuery::execute() @ 0x00000000148dcb0d 15. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88dc9 16. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 17. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 18. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 19. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 20. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 21. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 22. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 23. ? @ 0x00007fbc6213eac3 24. ? @ 0x00007fbc621d0850 2025.07.28 11:57:15.518677 [ 3964 ] {} test_13.rmt2 (7f9b740d-015c-470e-8cc6-8ba33be0dc63): auto DB::StorageReplicatedMergeTree::processQueueEntry(ReplicatedMergeTreeQueue::SelectedEntryPtr)::(anonymous class)::operator()(LogEntryPtr &) const: Code: 86. DB::HTTPException: Received error from remote server http://146b4357c08d:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Ftest%2F01165%2Ftest_13%2Frmt%2Freplicas%2F1&part=20250728_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.6.10636.altinitytest (altinity build)) '. (RECEIVED_ERROR_FROM_REMOTE_IO_SERVER), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.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 const&, int&&, String const&, unsigned long&&, String const&) @ 0x000000000feda8d9 4. /build/src/IO/HTTPCommon.cpp:104: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x000000000feda6e2 5. /build/src/IO/HTTPCommon.cpp:93: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x000000000feda537 6. /build/src/IO/ReadWriteBufferFromHTTP.cpp:277: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x000000001184a4c4 7. /build/src/IO/ReadWriteBufferFromHTTP.cpp:285: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x000000001184a615 8. /build/src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x000000001184ae59 9. /build/src/IO/ReadWriteBufferFromHTTP.cpp:472: void std::__function::__policy_invoker::__call_impl[abi:se190107]>(std::__function::__policy_storage const*) @ 0x000000001184cedd 10. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001184858b 11. /build/src/IO/ReadWriteBufferFromHTTP.cpp:465: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x000000001184bf0b 12. /build/src/IO/ReadBuffer.h:60: DB::ReadBuffer::next() @ 0x000000000a148c7b 13. /build/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) @ 0x0000000011849fb2 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]>&)>&, 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&) @ 0x0000000011841980 15. /build/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) @ 0x000000001621208e 16. /build/src/Storages/StorageReplicatedMergeTree.cpp:5228: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl[abi:se190107] const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000015f9a5fe 17. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000015ed8bfd 18. /build/src/Storages/StorageReplicatedMergeTree.cpp:2514: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x0000000015ec9aab 19. /build/src/Storages/StorageReplicatedMergeTree.cpp:2349: DB::StorageReplicatedMergeTree::executeLogEntry(DB::ReplicatedMergeTreeLogEntry&) @ 0x0000000015eba91b 20. /build/src/Storages/StorageReplicatedMergeTree.cpp:3876: bool std::__function::__policy_invoker&)>::__call_impl[abi:se190107])::$_1, bool (std::shared_ptr&)>>(std::__function::__policy_storage const*, std::shared_ptr&) @ 0x0000000015f9837e 21. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000165d6fc3 22. /build/src/Storages/StorageReplicatedMergeTree.cpp:3872: DB::StorageReplicatedMergeTree::processQueueEntry(std::shared_ptr) @ 0x0000000015efc18a 23. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001624c1b2 24. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000162f9c70 25. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x00000000162fa55a 26. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc6653 27. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000000fccc4c3 28. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc3d92 29. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fcca080 30. ? @ 0x00007fbc6213eac3 31. ? @ 0x00007fbc621d0850 (version 25.3.6.10636.altinitytest (altinity build)) 2025.07.28 11:57:15.962075 [ 3285 ] {99df2ee2-d6f3-4d9f-aa84-bf624c98aad2} executeQuery: Code: 48. DB::Exception: Truncate is not supported by storage Null. (NOT_IMPLEMENTED) (version 25.3.6.10636.altinitytest (altinity build)) (from 0.0.0.0:0) (comment: 01746_forbid_drop_column_referenced_by_mv.sql) (in query: /* ddl_entry=query-0000000014 */ TRUNCATE TABLE test_hz72qx47.`01746_null`), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x000000000a06b56b 4. /build/src/Storages/IStorage.cpp:171: DB::IStorage::truncate(std::shared_ptr const&, std::shared_ptr const&, std::shared_ptr, DB::TableExclusiveLockHolder&) @ 0x0000000015d1ec7a 5. /build/src/Interpreters/InterpreterDropQuery.cpp:282: DB::InterpreterDropQuery::executeToTableImpl(std::shared_ptr const&, DB::ASTDropQuery&, std::shared_ptr&, StrongTypedef, DB::UUIDTag>&) @ 0x0000000014915304 6. /build/src/Interpreters/InterpreterDropQuery.cpp:118: DB::InterpreterDropQuery::executeToTable(DB::ASTDropQuery&) @ 0x00000000149137b4 7. /build/src/Interpreters/InterpreterDropQuery.cpp:91: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000014912f07 8. /build/src/Interpreters/InterpreterDropQuery.cpp:72: DB::InterpreterDropQuery::execute() @ 0x0000000014912b65 9. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88dc9 10. /build/src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x0000000014c8ca7b 11. /build/src/Interpreters/DDLWorker.cpp:510: DB::DDLWorker::tryExecuteQuery(DB::DDLTaskBase&, std::shared_ptr const&, bool) @ 0x00000000144dab9e 12. /build/src/Interpreters/DDLWorker.cpp:675: DB::DDLWorker::processTask(DB::DDLTaskBase&, std::shared_ptr const&, bool) @ 0x00000000144d8ffe 13. /build/src/Databases/DatabaseReplicatedWorker.cpp:372: DB::DatabaseReplicatedDDLWorker::tryEnqueueAndExecuteEntry(DB::DDLLogEntry&, std::shared_ptr, bool) @ 0x0000000013dc29ab 14. /build/src/Databases/DatabaseReplicated.cpp:1139: DB::DatabaseReplicated::tryEnqueueReplicatedDDL(std::shared_ptr const&, std::shared_ptr, DB::QueryFlags) @ 0x0000000013d9f73c 15. /build/src/Interpreters/InterpreterDropQuery.cpp:226: DB::InterpreterDropQuery::executeToTableImpl(std::shared_ptr const&, DB::ASTDropQuery&, std::shared_ptr&, StrongTypedef, DB::UUIDTag>&) @ 0x0000000014914ed7 16. /build/src/Interpreters/InterpreterDropQuery.cpp:118: DB::InterpreterDropQuery::executeToTable(DB::ASTDropQuery&) @ 0x00000000149137b4 17. /build/src/Interpreters/InterpreterDropQuery.cpp:91: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000014912f07 18. /build/src/Interpreters/InterpreterDropQuery.cpp:72: DB::InterpreterDropQuery::execute() @ 0x0000000014912b65 19. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88dc9 20. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 21. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 22. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 23. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 24. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 25. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 26. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 27. ? @ 0x00007fbc6213eac3 28. ? @ 0x00007fbc621d0850 2025.07.28 11:57:15.986667 [ 3285 ] {99df2ee2-d6f3-4d9f-aa84-bf624c98aad2} executeQuery: Code: 48. DB::Exception: Truncate is not supported by storage Null. (NOT_IMPLEMENTED) (version 25.3.6.10636.altinitytest (altinity build)) (from [::1]:41286) (comment: 01746_forbid_drop_column_referenced_by_mv.sql) (query 17, line 62) (in query: DROP TABLE `01746_null`;), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x000000000a06b56b 4. /build/src/Storages/IStorage.cpp:171: DB::IStorage::truncate(std::shared_ptr const&, std::shared_ptr const&, std::shared_ptr, DB::TableExclusiveLockHolder&) @ 0x0000000015d1ec7a 5. /build/src/Interpreters/InterpreterDropQuery.cpp:282: DB::InterpreterDropQuery::executeToTableImpl(std::shared_ptr const&, DB::ASTDropQuery&, std::shared_ptr&, StrongTypedef, DB::UUIDTag>&) @ 0x0000000014915304 6. /build/src/Interpreters/InterpreterDropQuery.cpp:118: DB::InterpreterDropQuery::executeToTable(DB::ASTDropQuery&) @ 0x00000000149137b4 7. /build/src/Interpreters/InterpreterDropQuery.cpp:91: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000014912f07 8. /build/src/Interpreters/InterpreterDropQuery.cpp:72: DB::InterpreterDropQuery::execute() @ 0x0000000014912b65 9. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88dc9 10. /build/src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x0000000014c8ca7b 11. /build/src/Interpreters/DDLWorker.cpp:510: DB::DDLWorker::tryExecuteQuery(DB::DDLTaskBase&, std::shared_ptr const&, bool) @ 0x00000000144dab9e 12. /build/src/Interpreters/DDLWorker.cpp:675: DB::DDLWorker::processTask(DB::DDLTaskBase&, std::shared_ptr const&, bool) @ 0x00000000144d8ffe 13. /build/src/Databases/DatabaseReplicatedWorker.cpp:372: DB::DatabaseReplicatedDDLWorker::tryEnqueueAndExecuteEntry(DB::DDLLogEntry&, std::shared_ptr, bool) @ 0x0000000013dc29ab 14. /build/src/Databases/DatabaseReplicated.cpp:1139: DB::DatabaseReplicated::tryEnqueueReplicatedDDL(std::shared_ptr const&, std::shared_ptr, DB::QueryFlags) @ 0x0000000013d9f73c 15. /build/src/Interpreters/InterpreterDropQuery.cpp:226: DB::InterpreterDropQuery::executeToTableImpl(std::shared_ptr const&, DB::ASTDropQuery&, std::shared_ptr&, StrongTypedef, DB::UUIDTag>&) @ 0x0000000014914ed7 16. /build/src/Interpreters/InterpreterDropQuery.cpp:118: DB::InterpreterDropQuery::executeToTable(DB::ASTDropQuery&) @ 0x00000000149137b4 17. /build/src/Interpreters/InterpreterDropQuery.cpp:91: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000014912f07 18. /build/src/Interpreters/InterpreterDropQuery.cpp:72: DB::InterpreterDropQuery::execute() @ 0x0000000014912b65 19. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88dc9 20. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 21. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 22. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 23. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 24. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 25. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 26. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 27. ? @ 0x00007fbc6213eac3 28. ? @ 0x00007fbc621d0850 2025.07.28 11:57:15.995981 [ 3285 ] {} 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. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x000000000a06b56b 4. /build/src/Storages/IStorage.cpp:171: DB::IStorage::truncate(std::shared_ptr const&, std::shared_ptr const&, std::shared_ptr, DB::TableExclusiveLockHolder&) @ 0x0000000015d1ec7a 5. /build/src/Interpreters/InterpreterDropQuery.cpp:282: DB::InterpreterDropQuery::executeToTableImpl(std::shared_ptr const&, DB::ASTDropQuery&, std::shared_ptr&, StrongTypedef, DB::UUIDTag>&) @ 0x0000000014915304 6. /build/src/Interpreters/InterpreterDropQuery.cpp:118: DB::InterpreterDropQuery::executeToTable(DB::ASTDropQuery&) @ 0x00000000149137b4 7. /build/src/Interpreters/InterpreterDropQuery.cpp:91: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000014912f07 8. /build/src/Interpreters/InterpreterDropQuery.cpp:72: DB::InterpreterDropQuery::execute() @ 0x0000000014912b65 9. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88dc9 10. /build/src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x0000000014c8ca7b 11. /build/src/Interpreters/DDLWorker.cpp:510: DB::DDLWorker::tryExecuteQuery(DB::DDLTaskBase&, std::shared_ptr const&, bool) @ 0x00000000144dab9e 12. /build/src/Interpreters/DDLWorker.cpp:675: DB::DDLWorker::processTask(DB::DDLTaskBase&, std::shared_ptr const&, bool) @ 0x00000000144d8ffe 13. /build/src/Databases/DatabaseReplicatedWorker.cpp:372: DB::DatabaseReplicatedDDLWorker::tryEnqueueAndExecuteEntry(DB::DDLLogEntry&, std::shared_ptr, bool) @ 0x0000000013dc29ab 14. /build/src/Databases/DatabaseReplicated.cpp:1139: DB::DatabaseReplicated::tryEnqueueReplicatedDDL(std::shared_ptr const&, std::shared_ptr, DB::QueryFlags) @ 0x0000000013d9f73c 15. /build/src/Interpreters/InterpreterDropQuery.cpp:226: DB::InterpreterDropQuery::executeToTableImpl(std::shared_ptr const&, DB::ASTDropQuery&, std::shared_ptr&, StrongTypedef, DB::UUIDTag>&) @ 0x0000000014914ed7 16. /build/src/Interpreters/InterpreterDropQuery.cpp:118: DB::InterpreterDropQuery::executeToTable(DB::ASTDropQuery&) @ 0x00000000149137b4 17. /build/src/Interpreters/InterpreterDropQuery.cpp:91: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000014912f07 18. /build/src/Interpreters/InterpreterDropQuery.cpp:72: DB::InterpreterDropQuery::execute() @ 0x0000000014912b65 19. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88dc9 20. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 21. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 22. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 23. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 24. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 25. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 26. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 27. ? @ 0x00007fbc6213eac3 28. ? @ 0x00007fbc621d0850 2025.07.28 11:57:16.113880 [ 17243 ] {07bd33c1-5df1-434a-9f88-900241e4c3de} executeQuery: Code: 80. DB::Exception: It's not initial query. ON CLUSTER is not allowed for Replicated database. (INCORRECT_QUERY) (version 25.3.6.10636.altinitytest (altinity build)) (from [::1]:41980) (comment: 01746_forbid_drop_column_referenced_by_mv.sql) (in query: DROP DATABASE IF EXISTS test_hz72qx47 SYNC ), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000000a074fcb 4. /build/src/Databases/DatabaseReplicated.cpp:1128: DB::DatabaseReplicated::tryEnqueueReplicatedDDL(std::shared_ptr const&, std::shared_ptr, DB::QueryFlags) @ 0x0000000013da037d 5. /build/src/Interpreters/InterpreterDropQuery.cpp:226: DB::InterpreterDropQuery::executeToTableImpl(std::shared_ptr const&, DB::ASTDropQuery&, std::shared_ptr&, StrongTypedef, DB::UUIDTag>&) @ 0x0000000014914ed7 6. /build/src/Interpreters/InterpreterDropQuery.cpp:118: DB::InterpreterDropQuery::executeToTable(DB::ASTDropQuery&) @ 0x00000000149137b4 7. /build/src/Interpreters/InterpreterDropQuery.cpp:91: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000014912f07 8. /build/src/Interpreters/InterpreterDropQuery.cpp:72: DB::InterpreterDropQuery::execute() @ 0x0000000014912b65 9. /build/src/Interpreters/InterpreterDropQuery.cpp:579: DB::InterpreterDropQuery::executeDropQuery(DB::ASTDropQuery::Kind, std::shared_ptr, std::shared_ptr, DB::StorageID const&, bool, bool, bool) @ 0x0000000014918aa0 10. /build/src/Storages/StorageMaterializedView.cpp:481: DB::StorageMaterializedView::truncate(std::shared_ptr const&, std::shared_ptr const&, std::shared_ptr, DB::TableExclusiveLockHolder&) @ 0x0000000015e1fd56 11. /build/src/Interpreters/InterpreterDropQuery.cpp:282: DB::InterpreterDropQuery::executeToTableImpl(std::shared_ptr const&, DB::ASTDropQuery&, std::shared_ptr&, StrongTypedef, DB::UUIDTag>&) @ 0x0000000014915304 12. /build/src/Interpreters/InterpreterDropQuery.cpp:461: DB::InterpreterDropQuery::executeToDatabaseImpl(DB::ASTDropQuery const&, std::shared_ptr&, std::vector, DB::UUIDTag>, std::allocator, DB::UUIDTag>>>&) @ 0x0000000014917707 13. /build/src/Interpreters/InterpreterDropQuery.cpp:363: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x0000000014913988 14. /build/src/Interpreters/InterpreterDropQuery.cpp:99: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000014913142 15. /build/src/Interpreters/InterpreterDropQuery.cpp:72: DB::InterpreterDropQuery::execute() @ 0x0000000014912b65 16. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88dc9 17. /build/src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x0000000014c8ca7b 18. /build/src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000001686da12 19. /build/src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x0000000016870807 20. /build/src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x0000000016907e99 21. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 22. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 23. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 24. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 25. ? @ 0x00007fbc6213eac3 26. ? @ 0x00007fbc621d0850 2025.07.28 11:57:16.116466 [ 17243 ] {07bd33c1-5df1-434a-9f88-900241e4c3de} DynamicQueryHandler: 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. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000000a074fcb 4. /build/src/Databases/DatabaseReplicated.cpp:1128: DB::DatabaseReplicated::tryEnqueueReplicatedDDL(std::shared_ptr const&, std::shared_ptr, DB::QueryFlags) @ 0x0000000013da037d 5. /build/src/Interpreters/InterpreterDropQuery.cpp:226: DB::InterpreterDropQuery::executeToTableImpl(std::shared_ptr const&, DB::ASTDropQuery&, std::shared_ptr&, StrongTypedef, DB::UUIDTag>&) @ 0x0000000014914ed7 6. /build/src/Interpreters/InterpreterDropQuery.cpp:118: DB::InterpreterDropQuery::executeToTable(DB::ASTDropQuery&) @ 0x00000000149137b4 7. /build/src/Interpreters/InterpreterDropQuery.cpp:91: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000014912f07 8. /build/src/Interpreters/InterpreterDropQuery.cpp:72: DB::InterpreterDropQuery::execute() @ 0x0000000014912b65 9. /build/src/Interpreters/InterpreterDropQuery.cpp:579: DB::InterpreterDropQuery::executeDropQuery(DB::ASTDropQuery::Kind, std::shared_ptr, std::shared_ptr, DB::StorageID const&, bool, bool, bool) @ 0x0000000014918aa0 10. /build/src/Storages/StorageMaterializedView.cpp:481: DB::StorageMaterializedView::truncate(std::shared_ptr const&, std::shared_ptr const&, std::shared_ptr, DB::TableExclusiveLockHolder&) @ 0x0000000015e1fd56 11. /build/src/Interpreters/InterpreterDropQuery.cpp:282: DB::InterpreterDropQuery::executeToTableImpl(std::shared_ptr const&, DB::ASTDropQuery&, std::shared_ptr&, StrongTypedef, DB::UUIDTag>&) @ 0x0000000014915304 12. /build/src/Interpreters/InterpreterDropQuery.cpp:461: DB::InterpreterDropQuery::executeToDatabaseImpl(DB::ASTDropQuery const&, std::shared_ptr&, std::vector, DB::UUIDTag>, std::allocator, DB::UUIDTag>>>&) @ 0x0000000014917707 13. /build/src/Interpreters/InterpreterDropQuery.cpp:363: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x0000000014913988 14. /build/src/Interpreters/InterpreterDropQuery.cpp:99: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000014913142 15. /build/src/Interpreters/InterpreterDropQuery.cpp:72: DB::InterpreterDropQuery::execute() @ 0x0000000014912b65 16. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88dc9 17. /build/src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x0000000014c8ca7b 18. /build/src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000001686da12 19. /build/src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x0000000016870807 20. /build/src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x0000000016907e99 21. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 22. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 23. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 24. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 25. ? @ 0x00007fbc6213eac3 26. ? @ 0x00007fbc621d0850 (version 25.3.6.10636.altinitytest (altinity build)) 2025.07.28 11:57:16.179399 [ 17207 ] {a2a897af-d2d9-41a0-90e0-2f342ed79a7f} executeQuery: Code: 253. DB::Exception: Replica r1 of shard s1 of replicated database at /test/db/test_2 already exists. Replica host ID: '146b4357c08d:9000:19e16180-af7f-43fc-bc12-c25b4ab53332', current host ID: '146b4357c08d:9000:9ba14931-e0e8-4aa6-9e19-a27c3b5329c8'. (REPLICA_ALREADY_EXISTS) (version 25.3.6.10636.altinitytest (altinity build)) (from [::1]:41996) (comment: 02916_date_text_parsing.sql) (in query: CREATE DATABASE IF NOT EXISTS test_8eruar4r ENGINE=Replicated('/test/db/test_2', 's1', 'r1') ), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.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&) @ 0x0000000013db5399 4. /build/src/Databases/DatabaseReplicated.cpp:494: DB::DatabaseReplicated::tryConnectToZooKeeperAndInitDatabase(DB::LoadingStrictnessLevel) @ 0x0000000013d91155 5. /build/src/Databases/DatabaseReplicated.cpp:735: DB::DatabaseReplicated::beforeLoadingMetadata(std::shared_ptr, DB::LoadingStrictnessLevel) @ 0x0000000013d954d4 6. /build/src/Databases/TablesLoader.cpp:57: DB::TablesLoader::loadTablesAsync(std::unordered_set, std::hash>, std::equal_to>, std::allocator>>) @ 0x000000001490e734 7. /build/src/Interpreters/InterpreterCreateQuery.cpp:383: DB::InterpreterCreateQuery::createDatabase(DB::ASTCreateQuery&) @ 0x00000000148e8e14 8. /build/src/Interpreters/InterpreterCreateQuery.cpp:2351: DB::InterpreterCreateQuery::execute() @ 0x0000000014905a3a 9. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88dc9 10. /build/src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x0000000014c8ca7b 11. /build/src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000001686da12 12. /build/src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x0000000016870807 13. /build/src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x0000000016907e99 14. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 15. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 16. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 17. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 18. ? @ 0x00007fbc6213eac3 19. ? @ 0x00007fbc621d0850 2025.07.28 11:57:16.181361 [ 17207 ] {a2a897af-d2d9-41a0-90e0-2f342ed79a7f} DynamicQueryHandler: Code: 253. DB::Exception: Replica r1 of shard s1 of replicated database at /test/db/test_2 already exists. Replica host ID: '146b4357c08d:9000:19e16180-af7f-43fc-bc12-c25b4ab53332', current host ID: '146b4357c08d:9000:9ba14931-e0e8-4aa6-9e19-a27c3b5329c8'. (REPLICA_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.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&) @ 0x0000000013db5399 4. /build/src/Databases/DatabaseReplicated.cpp:494: DB::DatabaseReplicated::tryConnectToZooKeeperAndInitDatabase(DB::LoadingStrictnessLevel) @ 0x0000000013d91155 5. /build/src/Databases/DatabaseReplicated.cpp:735: DB::DatabaseReplicated::beforeLoadingMetadata(std::shared_ptr, DB::LoadingStrictnessLevel) @ 0x0000000013d954d4 6. /build/src/Databases/TablesLoader.cpp:57: DB::TablesLoader::loadTablesAsync(std::unordered_set, std::hash>, std::equal_to>, std::allocator>>) @ 0x000000001490e734 7. /build/src/Interpreters/InterpreterCreateQuery.cpp:383: DB::InterpreterCreateQuery::createDatabase(DB::ASTCreateQuery&) @ 0x00000000148e8e14 8. /build/src/Interpreters/InterpreterCreateQuery.cpp:2351: DB::InterpreterCreateQuery::execute() @ 0x0000000014905a3a 9. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88dc9 10. /build/src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x0000000014c8ca7b 11. /build/src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000001686da12 12. /build/src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x0000000016870807 13. /build/src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x0000000016907e99 14. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 15. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 16. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 17. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 18. ? @ 0x00007fbc6213eac3 19. ? @ 0x00007fbc621d0850 (version 25.3.6.10636.altinitytest (altinity build)) 2025.07.28 11:57:16.280906 [ 5747 ] {479e9dfa-8c28-4e4f-8205-4edbe24fd8ef} executeQuery: Code: 253. DB::Exception: Replica r1 of shard s1 of replicated database at /test/db/test_2 already exists. Replica host ID: '146b4357c08d:9000:19e16180-af7f-43fc-bc12-c25b4ab53332', current host ID: '146b4357c08d:9000:d0cfdc0b-fd0e-4cc1-9ec0-80c199193e61'. (REPLICA_ALREADY_EXISTS) (version 25.3.6.10636.altinitytest (altinity build)) (from [::1]:42002) (comment: 03369_predicate_pushdown_enforce_literal_type.sql) (in query: CREATE DATABASE IF NOT EXISTS test_afcdddf5 ENGINE=Replicated('/test/db/test_2', 's1', 'r1') ), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.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&) @ 0x0000000013db5399 4. /build/src/Databases/DatabaseReplicated.cpp:494: DB::DatabaseReplicated::tryConnectToZooKeeperAndInitDatabase(DB::LoadingStrictnessLevel) @ 0x0000000013d91155 5. /build/src/Databases/DatabaseReplicated.cpp:735: DB::DatabaseReplicated::beforeLoadingMetadata(std::shared_ptr, DB::LoadingStrictnessLevel) @ 0x0000000013d954d4 6. /build/src/Databases/TablesLoader.cpp:57: DB::TablesLoader::loadTablesAsync(std::unordered_set, std::hash>, std::equal_to>, std::allocator>>) @ 0x000000001490e734 7. /build/src/Interpreters/InterpreterCreateQuery.cpp:383: DB::InterpreterCreateQuery::createDatabase(DB::ASTCreateQuery&) @ 0x00000000148e8e14 8. /build/src/Interpreters/InterpreterCreateQuery.cpp:2351: DB::InterpreterCreateQuery::execute() @ 0x0000000014905a3a 9. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88dc9 10. /build/src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x0000000014c8ca7b 11. /build/src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000001686da12 12. /build/src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x0000000016870807 13. /build/src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x0000000016907e99 14. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 15. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 16. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 17. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 18. ? @ 0x00007fbc6213eac3 19. ? @ 0x00007fbc621d0850 2025.07.28 11:57:16.282405 [ 5747 ] {479e9dfa-8c28-4e4f-8205-4edbe24fd8ef} DynamicQueryHandler: Code: 253. DB::Exception: Replica r1 of shard s1 of replicated database at /test/db/test_2 already exists. Replica host ID: '146b4357c08d:9000:19e16180-af7f-43fc-bc12-c25b4ab53332', current host ID: '146b4357c08d:9000:d0cfdc0b-fd0e-4cc1-9ec0-80c199193e61'. (REPLICA_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.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&) @ 0x0000000013db5399 4. /build/src/Databases/DatabaseReplicated.cpp:494: DB::DatabaseReplicated::tryConnectToZooKeeperAndInitDatabase(DB::LoadingStrictnessLevel) @ 0x0000000013d91155 5. /build/src/Databases/DatabaseReplicated.cpp:735: DB::DatabaseReplicated::beforeLoadingMetadata(std::shared_ptr, DB::LoadingStrictnessLevel) @ 0x0000000013d954d4 6. /build/src/Databases/TablesLoader.cpp:57: DB::TablesLoader::loadTablesAsync(std::unordered_set, std::hash>, std::equal_to>, std::allocator>>) @ 0x000000001490e734 7. /build/src/Interpreters/InterpreterCreateQuery.cpp:383: DB::InterpreterCreateQuery::createDatabase(DB::ASTCreateQuery&) @ 0x00000000148e8e14 8. /build/src/Interpreters/InterpreterCreateQuery.cpp:2351: DB::InterpreterCreateQuery::execute() @ 0x0000000014905a3a 9. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88dc9 10. /build/src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x0000000014c8ca7b 11. /build/src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000001686da12 12. /build/src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x0000000016870807 13. /build/src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x0000000016907e99 14. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 15. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 16. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 17. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 18. ? @ 0x00007fbc6213eac3 19. ? @ 0x00007fbc621d0850 (version 25.3.6.10636.altinitytest (altinity build)) 2025.07.28 11:57:16.332017 [ 17287 ] {c00347af-c145-4395-9ccd-12cf56cbf501} executeQuery: Code: 253. DB::Exception: Replica r1 of shard s1 of replicated database at /test/db/test_2 already exists. Replica host ID: '146b4357c08d:9000:19e16180-af7f-43fc-bc12-c25b4ab53332', current host ID: '146b4357c08d:9000:e7a4d29a-394c-4c76-b0df-cd8983414e8c'. (REPLICA_ALREADY_EXISTS) (version 25.3.6.10636.altinitytest (altinity build)) (from [::1]:42016) (comment: 02733_sparse_columns_reload.sql) (in query: CREATE DATABASE IF NOT EXISTS test_phottll7 ENGINE=Replicated('/test/db/test_2', 's1', 'r1') ), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.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&) @ 0x0000000013db5399 4. /build/src/Databases/DatabaseReplicated.cpp:494: DB::DatabaseReplicated::tryConnectToZooKeeperAndInitDatabase(DB::LoadingStrictnessLevel) @ 0x0000000013d91155 5. /build/src/Databases/DatabaseReplicated.cpp:735: DB::DatabaseReplicated::beforeLoadingMetadata(std::shared_ptr, DB::LoadingStrictnessLevel) @ 0x0000000013d954d4 6. /build/src/Databases/TablesLoader.cpp:57: DB::TablesLoader::loadTablesAsync(std::unordered_set, std::hash>, std::equal_to>, std::allocator>>) @ 0x000000001490e734 7. /build/src/Interpreters/InterpreterCreateQuery.cpp:383: DB::InterpreterCreateQuery::createDatabase(DB::ASTCreateQuery&) @ 0x00000000148e8e14 8. /build/src/Interpreters/InterpreterCreateQuery.cpp:2351: DB::InterpreterCreateQuery::execute() @ 0x0000000014905a3a 9. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88dc9 10. /build/src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x0000000014c8ca7b 11. /build/src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000001686da12 12. /build/src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x0000000016870807 13. /build/src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x0000000016907e99 14. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 15. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 16. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 17. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 18. ? @ 0x00007fbc6213eac3 19. ? @ 0x00007fbc621d0850 2025.07.28 11:57:16.348287 [ 17287 ] {c00347af-c145-4395-9ccd-12cf56cbf501} DynamicQueryHandler: Code: 253. DB::Exception: Replica r1 of shard s1 of replicated database at /test/db/test_2 already exists. Replica host ID: '146b4357c08d:9000:19e16180-af7f-43fc-bc12-c25b4ab53332', current host ID: '146b4357c08d:9000:e7a4d29a-394c-4c76-b0df-cd8983414e8c'. (REPLICA_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.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&) @ 0x0000000013db5399 4. /build/src/Databases/DatabaseReplicated.cpp:494: DB::DatabaseReplicated::tryConnectToZooKeeperAndInitDatabase(DB::LoadingStrictnessLevel) @ 0x0000000013d91155 5. /build/src/Databases/DatabaseReplicated.cpp:735: DB::DatabaseReplicated::beforeLoadingMetadata(std::shared_ptr, DB::LoadingStrictnessLevel) @ 0x0000000013d954d4 6. /build/src/Databases/TablesLoader.cpp:57: DB::TablesLoader::loadTablesAsync(std::unordered_set, std::hash>, std::equal_to>, std::allocator>>) @ 0x000000001490e734 7. /build/src/Interpreters/InterpreterCreateQuery.cpp:383: DB::InterpreterCreateQuery::createDatabase(DB::ASTCreateQuery&) @ 0x00000000148e8e14 8. /build/src/Interpreters/InterpreterCreateQuery.cpp:2351: DB::InterpreterCreateQuery::execute() @ 0x0000000014905a3a 9. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88dc9 10. /build/src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x0000000014c8ca7b 11. /build/src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000001686da12 12. /build/src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x0000000016870807 13. /build/src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x0000000016907e99 14. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 15. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 16. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 17. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 18. ? @ 0x00007fbc6213eac3 19. ? @ 0x00007fbc621d0850 (version 25.3.6.10636.altinitytest (altinity build)) 2025.07.28 11:57:16.368958 [ 3972 ] {} test_13.rmt2 (7f9b740d-015c-470e-8cc6-8ba33be0dc63): auto DB::StorageReplicatedMergeTree::processQueueEntry(ReplicatedMergeTreeQueue::SelectedEntryPtr)::(anonymous class)::operator()(LogEntryPtr &) const: Code: 86. DB::HTTPException: Received error from remote server http://146b4357c08d:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Ftest%2F01165%2Ftest_13%2Frmt%2Freplicas%2F1&part=20250728_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.6.10636.altinitytest (altinity build)) '. (RECEIVED_ERROR_FROM_REMOTE_IO_SERVER), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.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 const&, int&&, String const&, unsigned long&&, String const&) @ 0x000000000feda8d9 4. /build/src/IO/HTTPCommon.cpp:104: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x000000000feda6e2 5. /build/src/IO/HTTPCommon.cpp:93: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x000000000feda537 6. /build/src/IO/ReadWriteBufferFromHTTP.cpp:277: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x000000001184a4c4 7. /build/src/IO/ReadWriteBufferFromHTTP.cpp:285: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x000000001184a615 8. /build/src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x000000001184ae59 9. /build/src/IO/ReadWriteBufferFromHTTP.cpp:472: void std::__function::__policy_invoker::__call_impl[abi:se190107]>(std::__function::__policy_storage const*) @ 0x000000001184cedd 10. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001184858b 11. /build/src/IO/ReadWriteBufferFromHTTP.cpp:465: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x000000001184bf0b 12. /build/src/IO/ReadBuffer.h:60: DB::ReadBuffer::next() @ 0x000000000a148c7b 13. /build/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) @ 0x0000000011849fb2 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]>&)>&, 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&) @ 0x0000000011841980 15. /build/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) @ 0x000000001621208e 16. /build/src/Storages/StorageReplicatedMergeTree.cpp:5228: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl[abi:se190107] const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000015f9a5fe 17. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000015ed8bfd 18. /build/src/Storages/StorageReplicatedMergeTree.cpp:2514: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x0000000015ec9aab 19. /build/src/Storages/StorageReplicatedMergeTree.cpp:2349: DB::StorageReplicatedMergeTree::executeLogEntry(DB::ReplicatedMergeTreeLogEntry&) @ 0x0000000015eba91b 20. /build/src/Storages/StorageReplicatedMergeTree.cpp:3876: bool std::__function::__policy_invoker&)>::__call_impl[abi:se190107])::$_1, bool (std::shared_ptr&)>>(std::__function::__policy_storage const*, std::shared_ptr&) @ 0x0000000015f9837e 21. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000165d6fc3 22. /build/src/Storages/StorageReplicatedMergeTree.cpp:3872: DB::StorageReplicatedMergeTree::processQueueEntry(std::shared_ptr) @ 0x0000000015efc18a 23. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001624c1b2 24. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000162f9c70 25. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x00000000162fa55a 26. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc6653 27. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000000fccc4c3 28. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc3d92 29. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fcca080 30. ? @ 0x00007fbc6213eac3 31. ? @ 0x00007fbc621d0850 (version 25.3.6.10636.altinitytest (altinity build)) 2025.07.28 11:57:16.460421 [ 5747 ] {a3804770-f3ca-4bd9-8a85-35ee125c52cb} executeQuery: Code: 253. DB::Exception: Replica r1 of shard s1 of replicated database at /test/db/test_2 already exists. Replica host ID: '146b4357c08d:9000:19e16180-af7f-43fc-bc12-c25b4ab53332', current host ID: '146b4357c08d:9000:5d9a4e95-c806-4013-8689-9e7f675d295b'. (REPLICA_ALREADY_EXISTS) (version 25.3.6.10636.altinitytest (altinity build)) (from [::1]:42032) (comment: 00730_unicode_terminal_format.sql) (in query: CREATE DATABASE IF NOT EXISTS test_slbsapyx ENGINE=Replicated('/test/db/test_2', 's1', 'r1') ), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.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&) @ 0x0000000013db5399 4. /build/src/Databases/DatabaseReplicated.cpp:494: DB::DatabaseReplicated::tryConnectToZooKeeperAndInitDatabase(DB::LoadingStrictnessLevel) @ 0x0000000013d91155 5. /build/src/Databases/DatabaseReplicated.cpp:735: DB::DatabaseReplicated::beforeLoadingMetadata(std::shared_ptr, DB::LoadingStrictnessLevel) @ 0x0000000013d954d4 6. /build/src/Databases/TablesLoader.cpp:57: DB::TablesLoader::loadTablesAsync(std::unordered_set, std::hash>, std::equal_to>, std::allocator>>) @ 0x000000001490e734 7. /build/src/Interpreters/InterpreterCreateQuery.cpp:383: DB::InterpreterCreateQuery::createDatabase(DB::ASTCreateQuery&) @ 0x00000000148e8e14 8. /build/src/Interpreters/InterpreterCreateQuery.cpp:2351: DB::InterpreterCreateQuery::execute() @ 0x0000000014905a3a 9. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88dc9 10. /build/src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x0000000014c8ca7b 11. /build/src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000001686da12 12. /build/src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x0000000016870807 13. /build/src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x0000000016907e99 14. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 15. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 16. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 17. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 18. ? @ 0x00007fbc6213eac3 19. ? @ 0x00007fbc621d0850 2025.07.28 11:57:16.462957 [ 5747 ] {a3804770-f3ca-4bd9-8a85-35ee125c52cb} DynamicQueryHandler: Code: 253. DB::Exception: Replica r1 of shard s1 of replicated database at /test/db/test_2 already exists. Replica host ID: '146b4357c08d:9000:19e16180-af7f-43fc-bc12-c25b4ab53332', current host ID: '146b4357c08d:9000:5d9a4e95-c806-4013-8689-9e7f675d295b'. (REPLICA_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.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&) @ 0x0000000013db5399 4. /build/src/Databases/DatabaseReplicated.cpp:494: DB::DatabaseReplicated::tryConnectToZooKeeperAndInitDatabase(DB::LoadingStrictnessLevel) @ 0x0000000013d91155 5. /build/src/Databases/DatabaseReplicated.cpp:735: DB::DatabaseReplicated::beforeLoadingMetadata(std::shared_ptr, DB::LoadingStrictnessLevel) @ 0x0000000013d954d4 6. /build/src/Databases/TablesLoader.cpp:57: DB::TablesLoader::loadTablesAsync(std::unordered_set, std::hash>, std::equal_to>, std::allocator>>) @ 0x000000001490e734 7. /build/src/Interpreters/InterpreterCreateQuery.cpp:383: DB::InterpreterCreateQuery::createDatabase(DB::ASTCreateQuery&) @ 0x00000000148e8e14 8. /build/src/Interpreters/InterpreterCreateQuery.cpp:2351: DB::InterpreterCreateQuery::execute() @ 0x0000000014905a3a 9. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88dc9 10. /build/src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x0000000014c8ca7b 11. /build/src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000001686da12 12. /build/src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x0000000016870807 13. /build/src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x0000000016907e99 14. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 15. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 16. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 17. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 18. ? @ 0x00007fbc6213eac3 19. ? @ 0x00007fbc621d0850 (version 25.3.6.10636.altinitytest (altinity build)) 2025.07.28 11:57:16.510717 [ 5327 ] {0892cf27-a920-4cee-951c-0bbabbd5da39} executeQuery: Code: 253. DB::Exception: Replica r1 of shard s1 of replicated database at /test/db/test_2 already exists. Replica host ID: '146b4357c08d:9000:19e16180-af7f-43fc-bc12-c25b4ab53332', current host ID: '146b4357c08d:9000:757a5382-5ab6-478b-970c-ccfb2fcdaf36'. (REPLICA_ALREADY_EXISTS) (version 25.3.6.10636.altinitytest (altinity build)) (from [::1]:42038) (comment: 00135_duplicate_group_by_keys_segfault.sql) (in query: CREATE DATABASE IF NOT EXISTS test_x6rwyitk ENGINE=Replicated('/test/db/test_2', 's1', 'r1') ), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.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&) @ 0x0000000013db5399 4. /build/src/Databases/DatabaseReplicated.cpp:494: DB::DatabaseReplicated::tryConnectToZooKeeperAndInitDatabase(DB::LoadingStrictnessLevel) @ 0x0000000013d91155 5. /build/src/Databases/DatabaseReplicated.cpp:735: DB::DatabaseReplicated::beforeLoadingMetadata(std::shared_ptr, DB::LoadingStrictnessLevel) @ 0x0000000013d954d4 6. /build/src/Databases/TablesLoader.cpp:57: DB::TablesLoader::loadTablesAsync(std::unordered_set, std::hash>, std::equal_to>, std::allocator>>) @ 0x000000001490e734 7. /build/src/Interpreters/InterpreterCreateQuery.cpp:383: DB::InterpreterCreateQuery::createDatabase(DB::ASTCreateQuery&) @ 0x00000000148e8e14 8. /build/src/Interpreters/InterpreterCreateQuery.cpp:2351: DB::InterpreterCreateQuery::execute() @ 0x0000000014905a3a 9. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88dc9 10. /build/src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x0000000014c8ca7b 11. /build/src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000001686da12 12. /build/src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x0000000016870807 13. /build/src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x0000000016907e99 14. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 15. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 16. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 17. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 18. ? @ 0x00007fbc6213eac3 19. ? @ 0x00007fbc621d0850 2025.07.28 11:57:16.513766 [ 5327 ] {0892cf27-a920-4cee-951c-0bbabbd5da39} DynamicQueryHandler: Code: 253. DB::Exception: Replica r1 of shard s1 of replicated database at /test/db/test_2 already exists. Replica host ID: '146b4357c08d:9000:19e16180-af7f-43fc-bc12-c25b4ab53332', current host ID: '146b4357c08d:9000:757a5382-5ab6-478b-970c-ccfb2fcdaf36'. (REPLICA_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.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&) @ 0x0000000013db5399 4. /build/src/Databases/DatabaseReplicated.cpp:494: DB::DatabaseReplicated::tryConnectToZooKeeperAndInitDatabase(DB::LoadingStrictnessLevel) @ 0x0000000013d91155 5. /build/src/Databases/DatabaseReplicated.cpp:735: DB::DatabaseReplicated::beforeLoadingMetadata(std::shared_ptr, DB::LoadingStrictnessLevel) @ 0x0000000013d954d4 6. /build/src/Databases/TablesLoader.cpp:57: DB::TablesLoader::loadTablesAsync(std::unordered_set, std::hash>, std::equal_to>, std::allocator>>) @ 0x000000001490e734 7. /build/src/Interpreters/InterpreterCreateQuery.cpp:383: DB::InterpreterCreateQuery::createDatabase(DB::ASTCreateQuery&) @ 0x00000000148e8e14 8. /build/src/Interpreters/InterpreterCreateQuery.cpp:2351: DB::InterpreterCreateQuery::execute() @ 0x0000000014905a3a 9. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88dc9 10. /build/src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x0000000014c8ca7b 11. /build/src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000001686da12 12. /build/src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x0000000016870807 13. /build/src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x0000000016907e99 14. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 15. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 16. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 17. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 18. ? @ 0x00007fbc6213eac3 19. ? @ 0x00007fbc621d0850 (version 25.3.6.10636.altinitytest (altinity build)) 2025.07.28 11:57:16.624720 [ 17287 ] {dd799033-f8a2-4aba-bec0-3596f7057e82} executeQuery: Code: 253. DB::Exception: Replica r1 of shard s1 of replicated database at /test/db/test_2 already exists. Replica host ID: '146b4357c08d:9000:19e16180-af7f-43fc-bc12-c25b4ab53332', current host ID: '146b4357c08d:9000:03defab0-99bb-4742-8c3e-e90fe687c5c4'. (REPLICA_ALREADY_EXISTS) (version 25.3.6.10636.altinitytest (altinity build)) (from [::1]:42054) (comment: 00560_float_leading_plus_in_exponent.sql) (in query: CREATE DATABASE IF NOT EXISTS test_9o32ha5j ENGINE=Replicated('/test/db/test_2', 's1', 'r1') ), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.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&) @ 0x0000000013db5399 4. /build/src/Databases/DatabaseReplicated.cpp:494: DB::DatabaseReplicated::tryConnectToZooKeeperAndInitDatabase(DB::LoadingStrictnessLevel) @ 0x0000000013d91155 5. /build/src/Databases/DatabaseReplicated.cpp:735: DB::DatabaseReplicated::beforeLoadingMetadata(std::shared_ptr, DB::LoadingStrictnessLevel) @ 0x0000000013d954d4 6. /build/src/Databases/TablesLoader.cpp:57: DB::TablesLoader::loadTablesAsync(std::unordered_set, std::hash>, std::equal_to>, std::allocator>>) @ 0x000000001490e734 7. /build/src/Interpreters/InterpreterCreateQuery.cpp:383: DB::InterpreterCreateQuery::createDatabase(DB::ASTCreateQuery&) @ 0x00000000148e8e14 8. /build/src/Interpreters/InterpreterCreateQuery.cpp:2351: DB::InterpreterCreateQuery::execute() @ 0x0000000014905a3a 9. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88dc9 10. /build/src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x0000000014c8ca7b 11. /build/src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000001686da12 12. /build/src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x0000000016870807 13. /build/src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x0000000016907e99 14. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 15. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 16. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 17. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 18. ? @ 0x00007fbc6213eac3 19. ? @ 0x00007fbc621d0850 2025.07.28 11:57:16.627288 [ 3971 ] {} test_13.rmt2 (7f9b740d-015c-470e-8cc6-8ba33be0dc63): auto DB::StorageReplicatedMergeTree::processQueueEntry(ReplicatedMergeTreeQueue::SelectedEntryPtr)::(anonymous class)::operator()(LogEntryPtr &) const: Code: 86. DB::HTTPException: Received error from remote server http://146b4357c08d:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Ftest%2F01165%2Ftest_13%2Frmt%2Freplicas%2F1&part=20250728_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.6.10636.altinitytest (altinity build)) '. (RECEIVED_ERROR_FROM_REMOTE_IO_SERVER), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.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 const&, int&&, String const&, unsigned long&&, String const&) @ 0x000000000feda8d9 4. /build/src/IO/HTTPCommon.cpp:104: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x000000000feda6e2 5. /build/src/IO/HTTPCommon.cpp:93: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x000000000feda537 6. /build/src/IO/ReadWriteBufferFromHTTP.cpp:277: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x000000001184a4c4 7. /build/src/IO/ReadWriteBufferFromHTTP.cpp:285: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x000000001184a615 8. /build/src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x000000001184ae59 9. /build/src/IO/ReadWriteBufferFromHTTP.cpp:472: void std::__function::__policy_invoker::__call_impl[abi:se190107]>(std::__function::__policy_storage const*) @ 0x000000001184cedd 10. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001184858b 11. /build/src/IO/ReadWriteBufferFromHTTP.cpp:465: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x000000001184bf0b 12. /build/src/IO/ReadBuffer.h:60: DB::ReadBuffer::next() @ 0x000000000a148c7b 13. /build/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) @ 0x0000000011849fb2 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]>&)>&, 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&) @ 0x0000000011841980 15. /build/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) @ 0x000000001621208e 16. /build/src/Storages/StorageReplicatedMergeTree.cpp:5228: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl[abi:se190107] const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000015f9a5fe 17. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000015ed8bfd 18. /build/src/Storages/StorageReplicatedMergeTree.cpp:2514: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x0000000015ec9aab 19. /build/src/Storages/StorageReplicatedMergeTree.cpp:2349: DB::StorageReplicatedMergeTree::executeLogEntry(DB::ReplicatedMergeTreeLogEntry&) @ 0x0000000015eba91b 20. /build/src/Storages/StorageReplicatedMergeTree.cpp:3876: bool std::__function::__policy_invoker&)>::__call_impl[abi:se190107])::$_1, bool (std::shared_ptr&)>>(std::__function::__policy_storage const*, std::shared_ptr&) @ 0x0000000015f9837e 21. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000165d6fc3 22. /build/src/Storages/StorageReplicatedMergeTree.cpp:3872: DB::StorageReplicatedMergeTree::processQueueEntry(std::shared_ptr) @ 0x0000000015efc18a 23. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001624c1b2 24. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000162f9c70 25. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x00000000162fa55a 26. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc6653 27. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000000fccc4c3 28. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc3d92 29. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fcca080 30. ? @ 0x00007fbc6213eac3 31. ? @ 0x00007fbc621d0850 (version 25.3.6.10636.altinitytest (altinity build)) 2025.07.28 11:57:16.628471 [ 17287 ] {dd799033-f8a2-4aba-bec0-3596f7057e82} DynamicQueryHandler: Code: 253. DB::Exception: Replica r1 of shard s1 of replicated database at /test/db/test_2 already exists. Replica host ID: '146b4357c08d:9000:19e16180-af7f-43fc-bc12-c25b4ab53332', current host ID: '146b4357c08d:9000:03defab0-99bb-4742-8c3e-e90fe687c5c4'. (REPLICA_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.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&) @ 0x0000000013db5399 4. /build/src/Databases/DatabaseReplicated.cpp:494: DB::DatabaseReplicated::tryConnectToZooKeeperAndInitDatabase(DB::LoadingStrictnessLevel) @ 0x0000000013d91155 5. /build/src/Databases/DatabaseReplicated.cpp:735: DB::DatabaseReplicated::beforeLoadingMetadata(std::shared_ptr, DB::LoadingStrictnessLevel) @ 0x0000000013d954d4 6. /build/src/Databases/TablesLoader.cpp:57: DB::TablesLoader::loadTablesAsync(std::unordered_set, std::hash>, std::equal_to>, std::allocator>>) @ 0x000000001490e734 7. /build/src/Interpreters/InterpreterCreateQuery.cpp:383: DB::InterpreterCreateQuery::createDatabase(DB::ASTCreateQuery&) @ 0x00000000148e8e14 8. /build/src/Interpreters/InterpreterCreateQuery.cpp:2351: DB::InterpreterCreateQuery::execute() @ 0x0000000014905a3a 9. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88dc9 10. /build/src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x0000000014c8ca7b 11. /build/src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000001686da12 12. /build/src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x0000000016870807 13. /build/src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x0000000016907e99 14. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 15. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 16. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 17. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 18. ? @ 0x00007fbc6213eac3 19. ? @ 0x00007fbc621d0850 (version 25.3.6.10636.altinitytest (altinity build)) 2025.07.28 11:57:16.712748 [ 17207 ] {a736e27c-9dd3-4d4c-9995-80aaf86954d7} executeQuery: Code: 33. DB::Exception: Last saved offsset for File a.txt is bigger than file size (311 > 0). (CANNOT_READ_ALL_DATA) (version 25.3.6.10636.altinitytest (altinity build)) (from [::1]:41580) (comment: 02023_storage_filelog.sh) (query 1, line 1) (in query: select * from file_log order by k settings stream_like_engine_allow_direct_select=1;), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&, long long&&) @ 0x000000001609230b 4. /build/src/Storages/FileLog/StorageFileLog.cpp:512: DB::StorageFileLog::openFilesAndSetPos() @ 0x0000000016089ed0 5. /build/src/Storages/FileLog/StorageFileLog.cpp:135: DB::ReadFromStorageFileLog::makePipe() @ 0x0000000016092d87 6. /build/src/Processors/QueryPlan/ReadFromStreamLikeEngine.cpp:36: DB::ReadFromStreamLikeEngine::initializePipeline(DB::QueryPipelineBuilder&, DB::BuildQueryPipelineSettings const&) @ 0x0000000016e8e7d0 7. /build/src/Processors/QueryPlan/ISourceStep.cpp:20: DB::ISourceStep::updatePipeline(std::vector>, std::allocator>>>, DB::BuildQueryPipelineSettings const&) @ 0x0000000016dd18d0 8. /build/src/Processors/QueryPlan/QueryPlan.cpp:201: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x0000000016e0076f 9. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:275: DB::InterpreterSelectQueryAnalyzer::buildQueryPipeline() @ 0x0000000014974614 10. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:242: DB::InterpreterSelectQueryAnalyzer::execute() @ 0x000000001497439e 11. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88dc9 12. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 13. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 14. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 15. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 16. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 17. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 18. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 19. ? @ 0x00007fbc6213eac3 20. ? @ 0x00007fbc621d0850 2025.07.28 11:57:16.713907 [ 7625 ] {d12afb52-8022-4be0-9735-adab7de83dd7} executeQuery: Code: 253. DB::Exception: Replica r1 of shard s1 of replicated database at /test/db/test_2 already exists. Replica host ID: '146b4357c08d:9000:19e16180-af7f-43fc-bc12-c25b4ab53332', current host ID: '146b4357c08d:9000:8683703f-ecc5-412f-a7c5-d4a28f838896'. (REPLICA_ALREADY_EXISTS) (version 25.3.6.10636.altinitytest (altinity build)) (from [::1]:42062) (comment: 02477_s3_request_throttler.sh) (in query: CREATE DATABASE IF NOT EXISTS test_ovfx6mcf ENGINE=Replicated('/test/db/test_2', 's1', 'r1') ), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.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&) @ 0x0000000013db5399 4. /build/src/Databases/DatabaseReplicated.cpp:494: DB::DatabaseReplicated::tryConnectToZooKeeperAndInitDatabase(DB::LoadingStrictnessLevel) @ 0x0000000013d91155 5. /build/src/Databases/DatabaseReplicated.cpp:735: DB::DatabaseReplicated::beforeLoadingMetadata(std::shared_ptr, DB::LoadingStrictnessLevel) @ 0x0000000013d954d4 6. /build/src/Databases/TablesLoader.cpp:57: DB::TablesLoader::loadTablesAsync(std::unordered_set, std::hash>, std::equal_to>, std::allocator>>) @ 0x000000001490e734 7. /build/src/Interpreters/InterpreterCreateQuery.cpp:383: DB::InterpreterCreateQuery::createDatabase(DB::ASTCreateQuery&) @ 0x00000000148e8e14 8. /build/src/Interpreters/InterpreterCreateQuery.cpp:2351: DB::InterpreterCreateQuery::execute() @ 0x0000000014905a3a 9. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88dc9 10. /build/src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x0000000014c8ca7b 11. /build/src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000001686da12 12. /build/src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x0000000016870807 13. /build/src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x0000000016907e99 14. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 15. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 16. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 17. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 18. ? @ 0x00007fbc6213eac3 19. ? @ 0x00007fbc621d0850 2025.07.28 11:57:16.719618 [ 7625 ] {d12afb52-8022-4be0-9735-adab7de83dd7} DynamicQueryHandler: Code: 253. DB::Exception: Replica r1 of shard s1 of replicated database at /test/db/test_2 already exists. Replica host ID: '146b4357c08d:9000:19e16180-af7f-43fc-bc12-c25b4ab53332', current host ID: '146b4357c08d:9000:8683703f-ecc5-412f-a7c5-d4a28f838896'. (REPLICA_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.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&) @ 0x0000000013db5399 4. /build/src/Databases/DatabaseReplicated.cpp:494: DB::DatabaseReplicated::tryConnectToZooKeeperAndInitDatabase(DB::LoadingStrictnessLevel) @ 0x0000000013d91155 5. /build/src/Databases/DatabaseReplicated.cpp:735: DB::DatabaseReplicated::beforeLoadingMetadata(std::shared_ptr, DB::LoadingStrictnessLevel) @ 0x0000000013d954d4 6. /build/src/Databases/TablesLoader.cpp:57: DB::TablesLoader::loadTablesAsync(std::unordered_set, std::hash>, std::equal_to>, std::allocator>>) @ 0x000000001490e734 7. /build/src/Interpreters/InterpreterCreateQuery.cpp:383: DB::InterpreterCreateQuery::createDatabase(DB::ASTCreateQuery&) @ 0x00000000148e8e14 8. /build/src/Interpreters/InterpreterCreateQuery.cpp:2351: DB::InterpreterCreateQuery::execute() @ 0x0000000014905a3a 9. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88dc9 10. /build/src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x0000000014c8ca7b 11. /build/src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000001686da12 12. /build/src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x0000000016870807 13. /build/src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x0000000016907e99 14. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 15. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 16. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 17. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 18. ? @ 0x00007fbc6213eac3 19. ? @ 0x00007fbc621d0850 (version 25.3.6.10636.altinitytest (altinity build)) 2025.07.28 11:57:16.733026 [ 17207 ] {} TCPHandler: Code: 33. DB::Exception: Last saved offsset for File a.txt is bigger than file size (311 > 0). (CANNOT_READ_ALL_DATA), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&, long long&&) @ 0x000000001609230b 4. /build/src/Storages/FileLog/StorageFileLog.cpp:512: DB::StorageFileLog::openFilesAndSetPos() @ 0x0000000016089ed0 5. /build/src/Storages/FileLog/StorageFileLog.cpp:135: DB::ReadFromStorageFileLog::makePipe() @ 0x0000000016092d87 6. /build/src/Processors/QueryPlan/ReadFromStreamLikeEngine.cpp:36: DB::ReadFromStreamLikeEngine::initializePipeline(DB::QueryPipelineBuilder&, DB::BuildQueryPipelineSettings const&) @ 0x0000000016e8e7d0 7. /build/src/Processors/QueryPlan/ISourceStep.cpp:20: DB::ISourceStep::updatePipeline(std::vector>, std::allocator>>>, DB::BuildQueryPipelineSettings const&) @ 0x0000000016dd18d0 8. /build/src/Processors/QueryPlan/QueryPlan.cpp:201: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x0000000016e0076f 9. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:275: DB::InterpreterSelectQueryAnalyzer::buildQueryPipeline() @ 0x0000000014974614 10. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:242: DB::InterpreterSelectQueryAnalyzer::execute() @ 0x000000001497439e 11. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88dc9 12. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 13. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 14. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 15. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 16. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 17. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 18. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 19. ? @ 0x00007fbc6213eac3 20. ? @ 0x00007fbc621d0850 2025.07.28 11:57:16.892596 [ 17287 ] {1cbec408-64c2-4353-9c2a-16bbdf0a56ab} executeQuery: Code: 253. DB::Exception: Replica r1 of shard s1 of replicated database at /test/db/test_2 already exists. Replica host ID: '146b4357c08d:9000:19e16180-af7f-43fc-bc12-c25b4ab53332', current host ID: '146b4357c08d:9000:da6180b0-447a-41cb-b1ac-87af4070e28f'. (REPLICA_ALREADY_EXISTS) (version 25.3.6.10636.altinitytest (altinity build)) (from [::1]:42066) (comment: 02269_insert_select_with_format_without_schema_inference.sql) (in query: CREATE DATABASE IF NOT EXISTS test_ub1igzge ENGINE=Replicated('/test/db/test_2', 's1', 'r1') ), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.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&) @ 0x0000000013db5399 4. /build/src/Databases/DatabaseReplicated.cpp:494: DB::DatabaseReplicated::tryConnectToZooKeeperAndInitDatabase(DB::LoadingStrictnessLevel) @ 0x0000000013d91155 5. /build/src/Databases/DatabaseReplicated.cpp:735: DB::DatabaseReplicated::beforeLoadingMetadata(std::shared_ptr, DB::LoadingStrictnessLevel) @ 0x0000000013d954d4 6. /build/src/Databases/TablesLoader.cpp:57: DB::TablesLoader::loadTablesAsync(std::unordered_set, std::hash>, std::equal_to>, std::allocator>>) @ 0x000000001490e734 7. /build/src/Interpreters/InterpreterCreateQuery.cpp:383: DB::InterpreterCreateQuery::createDatabase(DB::ASTCreateQuery&) @ 0x00000000148e8e14 8. /build/src/Interpreters/InterpreterCreateQuery.cpp:2351: DB::InterpreterCreateQuery::execute() @ 0x0000000014905a3a 9. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88dc9 10. /build/src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x0000000014c8ca7b 11. /build/src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000001686da12 12. /build/src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x0000000016870807 13. /build/src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x0000000016907e99 14. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 15. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 16. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 17. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 18. ? @ 0x00007fbc6213eac3 19. ? @ 0x00007fbc621d0850 2025.07.28 11:57:16.894336 [ 17287 ] {1cbec408-64c2-4353-9c2a-16bbdf0a56ab} DynamicQueryHandler: Code: 253. DB::Exception: Replica r1 of shard s1 of replicated database at /test/db/test_2 already exists. Replica host ID: '146b4357c08d:9000:19e16180-af7f-43fc-bc12-c25b4ab53332', current host ID: '146b4357c08d:9000:da6180b0-447a-41cb-b1ac-87af4070e28f'. (REPLICA_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.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&) @ 0x0000000013db5399 4. /build/src/Databases/DatabaseReplicated.cpp:494: DB::DatabaseReplicated::tryConnectToZooKeeperAndInitDatabase(DB::LoadingStrictnessLevel) @ 0x0000000013d91155 5. /build/src/Databases/DatabaseReplicated.cpp:735: DB::DatabaseReplicated::beforeLoadingMetadata(std::shared_ptr, DB::LoadingStrictnessLevel) @ 0x0000000013d954d4 6. /build/src/Databases/TablesLoader.cpp:57: DB::TablesLoader::loadTablesAsync(std::unordered_set, std::hash>, std::equal_to>, std::allocator>>) @ 0x000000001490e734 7. /build/src/Interpreters/InterpreterCreateQuery.cpp:383: DB::InterpreterCreateQuery::createDatabase(DB::ASTCreateQuery&) @ 0x00000000148e8e14 8. /build/src/Interpreters/InterpreterCreateQuery.cpp:2351: DB::InterpreterCreateQuery::execute() @ 0x0000000014905a3a 9. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88dc9 10. /build/src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x0000000014c8ca7b 11. /build/src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000001686da12 12. /build/src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x0000000016870807 13. /build/src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x0000000016907e99 14. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 15. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 16. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 17. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 18. ? @ 0x00007fbc6213eac3 19. ? @ 0x00007fbc621d0850 (version 25.3.6.10636.altinitytest (altinity build)) 2025.07.28 11:57:16.963257 [ 7625 ] {d342f68c-7205-4a39-acfb-036821dfbe3b} executeQuery: Code: 253. DB::Exception: Replica r1 of shard s1 of replicated database at /test/db/test_2 already exists. Replica host ID: '146b4357c08d:9000:19e16180-af7f-43fc-bc12-c25b4ab53332', current host ID: '146b4357c08d:9000:e4e417ea-96ad-4764-913e-2fc1fe2a9bb2'. (REPLICA_ALREADY_EXISTS) (version 25.3.6.10636.altinitytest (altinity build)) (from [::1]:42074) (comment: 02158_ztest_cmp.sh) (in query: CREATE DATABASE IF NOT EXISTS test_pqicfqe7 ENGINE=Replicated('/test/db/test_2', 's1', 'r1') ), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.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&) @ 0x0000000013db5399 4. /build/src/Databases/DatabaseReplicated.cpp:494: DB::DatabaseReplicated::tryConnectToZooKeeperAndInitDatabase(DB::LoadingStrictnessLevel) @ 0x0000000013d91155 5. /build/src/Databases/DatabaseReplicated.cpp:735: DB::DatabaseReplicated::beforeLoadingMetadata(std::shared_ptr, DB::LoadingStrictnessLevel) @ 0x0000000013d954d4 6. /build/src/Databases/TablesLoader.cpp:57: DB::TablesLoader::loadTablesAsync(std::unordered_set, std::hash>, std::equal_to>, std::allocator>>) @ 0x000000001490e734 7. /build/src/Interpreters/InterpreterCreateQuery.cpp:383: DB::InterpreterCreateQuery::createDatabase(DB::ASTCreateQuery&) @ 0x00000000148e8e14 8. /build/src/Interpreters/InterpreterCreateQuery.cpp:2351: DB::InterpreterCreateQuery::execute() @ 0x0000000014905a3a 9. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88dc9 10. /build/src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x0000000014c8ca7b 11. /build/src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000001686da12 12. /build/src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x0000000016870807 13. /build/src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x0000000016907e99 14. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 15. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 16. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 17. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 18. ? @ 0x00007fbc6213eac3 19. ? @ 0x00007fbc621d0850 2025.07.28 11:57:16.973141 [ 7625 ] {d342f68c-7205-4a39-acfb-036821dfbe3b} DynamicQueryHandler: Code: 253. DB::Exception: Replica r1 of shard s1 of replicated database at /test/db/test_2 already exists. Replica host ID: '146b4357c08d:9000:19e16180-af7f-43fc-bc12-c25b4ab53332', current host ID: '146b4357c08d:9000:e4e417ea-96ad-4764-913e-2fc1fe2a9bb2'. (REPLICA_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.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&) @ 0x0000000013db5399 4. /build/src/Databases/DatabaseReplicated.cpp:494: DB::DatabaseReplicated::tryConnectToZooKeeperAndInitDatabase(DB::LoadingStrictnessLevel) @ 0x0000000013d91155 5. /build/src/Databases/DatabaseReplicated.cpp:735: DB::DatabaseReplicated::beforeLoadingMetadata(std::shared_ptr, DB::LoadingStrictnessLevel) @ 0x0000000013d954d4 6. /build/src/Databases/TablesLoader.cpp:57: DB::TablesLoader::loadTablesAsync(std::unordered_set, std::hash>, std::equal_to>, std::allocator>>) @ 0x000000001490e734 7. /build/src/Interpreters/InterpreterCreateQuery.cpp:383: DB::InterpreterCreateQuery::createDatabase(DB::ASTCreateQuery&) @ 0x00000000148e8e14 8. /build/src/Interpreters/InterpreterCreateQuery.cpp:2351: DB::InterpreterCreateQuery::execute() @ 0x0000000014905a3a 9. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88dc9 10. /build/src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x0000000014c8ca7b 11. /build/src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000001686da12 12. /build/src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x0000000016870807 13. /build/src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x0000000016907e99 14. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 15. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 16. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 17. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 18. ? @ 0x00007fbc6213eac3 19. ? @ 0x00007fbc621d0850 (version 25.3.6.10636.altinitytest (altinity build)) 2025.07.28 11:57:17.000453 [ 3965 ] {} test_13.rmt2 (7f9b740d-015c-470e-8cc6-8ba33be0dc63): auto DB::StorageReplicatedMergeTree::processQueueEntry(ReplicatedMergeTreeQueue::SelectedEntryPtr)::(anonymous class)::operator()(LogEntryPtr &) const: Code: 86. DB::HTTPException: Received error from remote server http://146b4357c08d:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Ftest%2F01165%2Ftest_13%2Frmt%2Freplicas%2F1&part=20250728_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.6.10636.altinitytest (altinity build)) '. (RECEIVED_ERROR_FROM_REMOTE_IO_SERVER), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.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 const&, int&&, String const&, unsigned long&&, String const&) @ 0x000000000feda8d9 4. /build/src/IO/HTTPCommon.cpp:104: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x000000000feda6e2 5. /build/src/IO/HTTPCommon.cpp:93: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x000000000feda537 6. /build/src/IO/ReadWriteBufferFromHTTP.cpp:277: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x000000001184a4c4 7. /build/src/IO/ReadWriteBufferFromHTTP.cpp:285: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x000000001184a615 8. /build/src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x000000001184ae59 9. /build/src/IO/ReadWriteBufferFromHTTP.cpp:472: void std::__function::__policy_invoker::__call_impl[abi:se190107]>(std::__function::__policy_storage const*) @ 0x000000001184cedd 10. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001184858b 11. /build/src/IO/ReadWriteBufferFromHTTP.cpp:465: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x000000001184bf0b 12. /build/src/IO/ReadBuffer.h:60: DB::ReadBuffer::next() @ 0x000000000a148c7b 13. /build/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) @ 0x0000000011849fb2 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]>&)>&, 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&) @ 0x0000000011841980 15. /build/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) @ 0x000000001621208e 16. /build/src/Storages/StorageReplicatedMergeTree.cpp:5228: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl[abi:se190107] const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000015f9a5fe 17. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000015ed8bfd 18. /build/src/Storages/StorageReplicatedMergeTree.cpp:2514: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x0000000015ec9aab 19. /build/src/Storages/StorageReplicatedMergeTree.cpp:2349: DB::StorageReplicatedMergeTree::executeLogEntry(DB::ReplicatedMergeTreeLogEntry&) @ 0x0000000015eba91b 20. /build/src/Storages/StorageReplicatedMergeTree.cpp:3876: bool std::__function::__policy_invoker&)>::__call_impl[abi:se190107])::$_1, bool (std::shared_ptr&)>>(std::__function::__policy_storage const*, std::shared_ptr&) @ 0x0000000015f9837e 21. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000165d6fc3 22. /build/src/Storages/StorageReplicatedMergeTree.cpp:3872: DB::StorageReplicatedMergeTree::processQueueEntry(std::shared_ptr) @ 0x0000000015efc18a 23. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001624c1b2 24. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000162f9c70 25. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x00000000162fa55a 26. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc6653 27. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000000fccc4c3 28. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc3d92 29. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fcca080 30. ? @ 0x00007fbc6213eac3 31. ? @ 0x00007fbc621d0850 (version 25.3.6.10636.altinitytest (altinity build)) 2025.07.28 11:57:17.030242 [ 17207 ] {170fd93b-ab9d-4111-bfe8-78bbf2dc24a5} executeQuery: Code: 253. DB::Exception: Replica r1 of shard s1 of replicated database at /test/db/test_2 already exists. Replica host ID: '146b4357c08d:9000:19e16180-af7f-43fc-bc12-c25b4ab53332', current host ID: '146b4357c08d:9000:2ea42198-94d3-47f8-a907-2d8104056eb3'. (REPLICA_ALREADY_EXISTS) (version 25.3.6.10636.altinitytest (altinity build)) (from [::1]:42088) (comment: 01703_rewrite_aggregate_function_case_insensitive.sql) (in query: CREATE DATABASE IF NOT EXISTS test_cv3ytijh ENGINE=Replicated('/test/db/test_2', 's1', 'r1') ), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.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&) @ 0x0000000013db5399 4. /build/src/Databases/DatabaseReplicated.cpp:494: DB::DatabaseReplicated::tryConnectToZooKeeperAndInitDatabase(DB::LoadingStrictnessLevel) @ 0x0000000013d91155 5. /build/src/Databases/DatabaseReplicated.cpp:735: DB::DatabaseReplicated::beforeLoadingMetadata(std::shared_ptr, DB::LoadingStrictnessLevel) @ 0x0000000013d954d4 6. /build/src/Databases/TablesLoader.cpp:57: DB::TablesLoader::loadTablesAsync(std::unordered_set, std::hash>, std::equal_to>, std::allocator>>) @ 0x000000001490e734 7. /build/src/Interpreters/InterpreterCreateQuery.cpp:383: DB::InterpreterCreateQuery::createDatabase(DB::ASTCreateQuery&) @ 0x00000000148e8e14 8. /build/src/Interpreters/InterpreterCreateQuery.cpp:2351: DB::InterpreterCreateQuery::execute() @ 0x0000000014905a3a 9. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88dc9 10. /build/src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x0000000014c8ca7b 11. /build/src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000001686da12 12. /build/src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x0000000016870807 13. /build/src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x0000000016907e99 14. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 15. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 16. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 17. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 18. ? @ 0x00007fbc6213eac3 19. ? @ 0x00007fbc621d0850 2025.07.28 11:57:17.040285 [ 17207 ] {170fd93b-ab9d-4111-bfe8-78bbf2dc24a5} DynamicQueryHandler: Code: 253. DB::Exception: Replica r1 of shard s1 of replicated database at /test/db/test_2 already exists. Replica host ID: '146b4357c08d:9000:19e16180-af7f-43fc-bc12-c25b4ab53332', current host ID: '146b4357c08d:9000:2ea42198-94d3-47f8-a907-2d8104056eb3'. (REPLICA_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.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&) @ 0x0000000013db5399 4. /build/src/Databases/DatabaseReplicated.cpp:494: DB::DatabaseReplicated::tryConnectToZooKeeperAndInitDatabase(DB::LoadingStrictnessLevel) @ 0x0000000013d91155 5. /build/src/Databases/DatabaseReplicated.cpp:735: DB::DatabaseReplicated::beforeLoadingMetadata(std::shared_ptr, DB::LoadingStrictnessLevel) @ 0x0000000013d954d4 6. /build/src/Databases/TablesLoader.cpp:57: DB::TablesLoader::loadTablesAsync(std::unordered_set, std::hash>, std::equal_to>, std::allocator>>) @ 0x000000001490e734 7. /build/src/Interpreters/InterpreterCreateQuery.cpp:383: DB::InterpreterCreateQuery::createDatabase(DB::ASTCreateQuery&) @ 0x00000000148e8e14 8. /build/src/Interpreters/InterpreterCreateQuery.cpp:2351: DB::InterpreterCreateQuery::execute() @ 0x0000000014905a3a 9. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88dc9 10. /build/src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x0000000014c8ca7b 11. /build/src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000001686da12 12. /build/src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x0000000016870807 13. /build/src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x0000000016907e99 14. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 15. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 16. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 17. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 18. ? @ 0x00007fbc6213eac3 19. ? @ 0x00007fbc621d0850 (version 25.3.6.10636.altinitytest (altinity build)) 2025.07.28 11:57:17.170507 [ 17287 ] {2b084f3a-d6c8-4e15-9378-90121508caf8} executeQuery: Code: 253. DB::Exception: Replica r1 of shard s1 of replicated database at /test/db/test_2 already exists. Replica host ID: '146b4357c08d:9000:19e16180-af7f-43fc-bc12-c25b4ab53332', current host ID: '146b4357c08d:9000:b4f860eb-0883-4dab-98ed-9503eb7bfc4d'. (REPLICA_ALREADY_EXISTS) (version 25.3.6.10636.altinitytest (altinity build)) (from [::1]:42096) (comment: 01358_constexpr_constraint.sql) (in query: CREATE DATABASE IF NOT EXISTS test_eivkz8at ENGINE=Replicated('/test/db/test_2', 's1', 'r1') ), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.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&) @ 0x0000000013db5399 4. /build/src/Databases/DatabaseReplicated.cpp:494: DB::DatabaseReplicated::tryConnectToZooKeeperAndInitDatabase(DB::LoadingStrictnessLevel) @ 0x0000000013d91155 5. /build/src/Databases/DatabaseReplicated.cpp:735: DB::DatabaseReplicated::beforeLoadingMetadata(std::shared_ptr, DB::LoadingStrictnessLevel) @ 0x0000000013d954d4 6. /build/src/Databases/TablesLoader.cpp:57: DB::TablesLoader::loadTablesAsync(std::unordered_set, std::hash>, std::equal_to>, std::allocator>>) @ 0x000000001490e734 7. /build/src/Interpreters/InterpreterCreateQuery.cpp:383: DB::InterpreterCreateQuery::createDatabase(DB::ASTCreateQuery&) @ 0x00000000148e8e14 8. /build/src/Interpreters/InterpreterCreateQuery.cpp:2351: DB::InterpreterCreateQuery::execute() @ 0x0000000014905a3a 9. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88dc9 10. /build/src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x0000000014c8ca7b 11. /build/src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000001686da12 12. /build/src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x0000000016870807 13. /build/src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x0000000016907e99 14. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 15. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 16. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 17. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 18. ? @ 0x00007fbc6213eac3 19. ? @ 0x00007fbc621d0850 2025.07.28 11:57:17.179195 [ 17287 ] {2b084f3a-d6c8-4e15-9378-90121508caf8} DynamicQueryHandler: Code: 253. DB::Exception: Replica r1 of shard s1 of replicated database at /test/db/test_2 already exists. Replica host ID: '146b4357c08d:9000:19e16180-af7f-43fc-bc12-c25b4ab53332', current host ID: '146b4357c08d:9000:b4f860eb-0883-4dab-98ed-9503eb7bfc4d'. (REPLICA_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.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&) @ 0x0000000013db5399 4. /build/src/Databases/DatabaseReplicated.cpp:494: DB::DatabaseReplicated::tryConnectToZooKeeperAndInitDatabase(DB::LoadingStrictnessLevel) @ 0x0000000013d91155 5. /build/src/Databases/DatabaseReplicated.cpp:735: DB::DatabaseReplicated::beforeLoadingMetadata(std::shared_ptr, DB::LoadingStrictnessLevel) @ 0x0000000013d954d4 6. /build/src/Databases/TablesLoader.cpp:57: DB::TablesLoader::loadTablesAsync(std::unordered_set, std::hash>, std::equal_to>, std::allocator>>) @ 0x000000001490e734 7. /build/src/Interpreters/InterpreterCreateQuery.cpp:383: DB::InterpreterCreateQuery::createDatabase(DB::ASTCreateQuery&) @ 0x00000000148e8e14 8. /build/src/Interpreters/InterpreterCreateQuery.cpp:2351: DB::InterpreterCreateQuery::execute() @ 0x0000000014905a3a 9. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88dc9 10. /build/src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x0000000014c8ca7b 11. /build/src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000001686da12 12. /build/src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x0000000016870807 13. /build/src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x0000000016907e99 14. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 15. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 16. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 17. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 18. ? @ 0x00007fbc6213eac3 19. ? @ 0x00007fbc621d0850 (version 25.3.6.10636.altinitytest (altinity build)) 2025.07.28 11:57:17.220809 [ 3963 ] {} test_13.rmt2 (7f9b740d-015c-470e-8cc6-8ba33be0dc63): auto DB::StorageReplicatedMergeTree::processQueueEntry(ReplicatedMergeTreeQueue::SelectedEntryPtr)::(anonymous class)::operator()(LogEntryPtr &) const: Code: 86. DB::HTTPException: Received error from remote server http://146b4357c08d:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Ftest%2F01165%2Ftest_13%2Frmt%2Freplicas%2F1&part=20250728_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.6.10636.altinitytest (altinity build)) '. (RECEIVED_ERROR_FROM_REMOTE_IO_SERVER), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.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 const&, int&&, String const&, unsigned long&&, String const&) @ 0x000000000feda8d9 4. /build/src/IO/HTTPCommon.cpp:104: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x000000000feda6e2 5. /build/src/IO/HTTPCommon.cpp:93: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x000000000feda537 6. /build/src/IO/ReadWriteBufferFromHTTP.cpp:277: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x000000001184a4c4 7. /build/src/IO/ReadWriteBufferFromHTTP.cpp:285: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x000000001184a615 8. /build/src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x000000001184ae59 9. /build/src/IO/ReadWriteBufferFromHTTP.cpp:472: void std::__function::__policy_invoker::__call_impl[abi:se190107]>(std::__function::__policy_storage const*) @ 0x000000001184cedd 10. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001184858b 11. /build/src/IO/ReadWriteBufferFromHTTP.cpp:465: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x000000001184bf0b 12. /build/src/IO/ReadBuffer.h:60: DB::ReadBuffer::next() @ 0x000000000a148c7b 13. /build/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) @ 0x0000000011849fb2 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]>&)>&, 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&) @ 0x0000000011841980 15. /build/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) @ 0x000000001621208e 16. /build/src/Storages/StorageReplicatedMergeTree.cpp:5228: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl[abi:se190107] const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000015f9a5fe 17. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000015ed8bfd 18. /build/src/Storages/StorageReplicatedMergeTree.cpp:2514: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x0000000015ec9aab 19. /build/src/Storages/StorageReplicatedMergeTree.cpp:2349: DB::StorageReplicatedMergeTree::executeLogEntry(DB::ReplicatedMergeTreeLogEntry&) @ 0x0000000015eba91b 20. /build/src/Storages/StorageReplicatedMergeTree.cpp:3876: bool std::__function::__policy_invoker&)>::__call_impl[abi:se190107])::$_1, bool (std::shared_ptr&)>>(std::__function::__policy_storage const*, std::shared_ptr&) @ 0x0000000015f9837e 21. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000165d6fc3 22. /build/src/Storages/StorageReplicatedMergeTree.cpp:3872: DB::StorageReplicatedMergeTree::processQueueEntry(std::shared_ptr) @ 0x0000000015efc18a 23. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001624c1b2 24. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000162f9c70 25. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x00000000162fa55a 26. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc6653 27. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000000fccc4c3 28. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc3d92 29. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fcca080 30. ? @ 0x00007fbc6213eac3 31. ? @ 0x00007fbc621d0850 (version 25.3.6.10636.altinitytest (altinity build)) 2025.07.28 11:57:17.277156 [ 3287 ] {d7028222-b449-405e-ab0f-e0ed50d1e298} executeQuery: Code: 253. DB::Exception: Replica r1 of shard s1 of replicated database at /test/db/test_2 already exists. Replica host ID: '146b4357c08d:9000:19e16180-af7f-43fc-bc12-c25b4ab53332', current host ID: '146b4357c08d:9000:09398dac-4f1e-4803-bfae-be4b3d6f600d'. (REPLICA_ALREADY_EXISTS) (version 25.3.6.10636.altinitytest (altinity build)) (from [::1]:42112) (comment: 01017_uniqCombined_memory_usage.sql) (in query: CREATE DATABASE IF NOT EXISTS test_x6sxw9op ENGINE=Replicated('/test/db/test_2', 's1', 'r1') ), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.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&) @ 0x0000000013db5399 4. /build/src/Databases/DatabaseReplicated.cpp:494: DB::DatabaseReplicated::tryConnectToZooKeeperAndInitDatabase(DB::LoadingStrictnessLevel) @ 0x0000000013d91155 5. /build/src/Databases/DatabaseReplicated.cpp:735: DB::DatabaseReplicated::beforeLoadingMetadata(std::shared_ptr, DB::LoadingStrictnessLevel) @ 0x0000000013d954d4 6. /build/src/Databases/TablesLoader.cpp:57: DB::TablesLoader::loadTablesAsync(std::unordered_set, std::hash>, std::equal_to>, std::allocator>>) @ 0x000000001490e734 7. /build/src/Interpreters/InterpreterCreateQuery.cpp:383: DB::InterpreterCreateQuery::createDatabase(DB::ASTCreateQuery&) @ 0x00000000148e8e14 8. /build/src/Interpreters/InterpreterCreateQuery.cpp:2351: DB::InterpreterCreateQuery::execute() @ 0x0000000014905a3a 9. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88dc9 10. /build/src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x0000000014c8ca7b 11. /build/src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000001686da12 12. /build/src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x0000000016870807 13. /build/src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x0000000016907e99 14. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 15. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 16. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 17. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 18. ? @ 0x00007fbc6213eac3 19. ? @ 0x00007fbc621d0850 2025.07.28 11:57:17.286369 [ 3287 ] {d7028222-b449-405e-ab0f-e0ed50d1e298} DynamicQueryHandler: Code: 253. DB::Exception: Replica r1 of shard s1 of replicated database at /test/db/test_2 already exists. Replica host ID: '146b4357c08d:9000:19e16180-af7f-43fc-bc12-c25b4ab53332', current host ID: '146b4357c08d:9000:09398dac-4f1e-4803-bfae-be4b3d6f600d'. (REPLICA_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.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&) @ 0x0000000013db5399 4. /build/src/Databases/DatabaseReplicated.cpp:494: DB::DatabaseReplicated::tryConnectToZooKeeperAndInitDatabase(DB::LoadingStrictnessLevel) @ 0x0000000013d91155 5. /build/src/Databases/DatabaseReplicated.cpp:735: DB::DatabaseReplicated::beforeLoadingMetadata(std::shared_ptr, DB::LoadingStrictnessLevel) @ 0x0000000013d954d4 6. /build/src/Databases/TablesLoader.cpp:57: DB::TablesLoader::loadTablesAsync(std::unordered_set, std::hash>, std::equal_to>, std::allocator>>) @ 0x000000001490e734 7. /build/src/Interpreters/InterpreterCreateQuery.cpp:383: DB::InterpreterCreateQuery::createDatabase(DB::ASTCreateQuery&) @ 0x00000000148e8e14 8. /build/src/Interpreters/InterpreterCreateQuery.cpp:2351: DB::InterpreterCreateQuery::execute() @ 0x0000000014905a3a 9. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88dc9 10. /build/src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x0000000014c8ca7b 11. /build/src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000001686da12 12. /build/src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x0000000016870807 13. /build/src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x0000000016907e99 14. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 15. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 16. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 17. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 18. ? @ 0x00007fbc6213eac3 19. ? @ 0x00007fbc621d0850 (version 25.3.6.10636.altinitytest (altinity build)) 2025.07.28 11:57:17.387629 [ 3976 ] {} test_13.rmt2 (7f9b740d-015c-470e-8cc6-8ba33be0dc63): auto DB::StorageReplicatedMergeTree::processQueueEntry(ReplicatedMergeTreeQueue::SelectedEntryPtr)::(anonymous class)::operator()(LogEntryPtr &) const: Code: 86. DB::HTTPException: Received error from remote server http://146b4357c08d:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Ftest%2F01165%2Ftest_13%2Frmt%2Freplicas%2F1&part=20250728_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.6.10636.altinitytest (altinity build)) '. (RECEIVED_ERROR_FROM_REMOTE_IO_SERVER), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.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 const&, int&&, String const&, unsigned long&&, String const&) @ 0x000000000feda8d9 4. /build/src/IO/HTTPCommon.cpp:104: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x000000000feda6e2 5. /build/src/IO/HTTPCommon.cpp:93: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x000000000feda537 6. /build/src/IO/ReadWriteBufferFromHTTP.cpp:277: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x000000001184a4c4 7. /build/src/IO/ReadWriteBufferFromHTTP.cpp:285: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x000000001184a615 8. /build/src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x000000001184ae59 9. /build/src/IO/ReadWriteBufferFromHTTP.cpp:472: void std::__function::__policy_invoker::__call_impl[abi:se190107]>(std::__function::__policy_storage const*) @ 0x000000001184cedd 10. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001184858b 11. /build/src/IO/ReadWriteBufferFromHTTP.cpp:465: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x000000001184bf0b 12. /build/src/IO/ReadBuffer.h:60: DB::ReadBuffer::next() @ 0x000000000a148c7b 13. /build/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) @ 0x0000000011849fb2 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]>&)>&, 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&) @ 0x0000000011841980 15. /build/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) @ 0x000000001621208e 16. /build/src/Storages/StorageReplicatedMergeTree.cpp:5228: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl[abi:se190107] const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000015f9a5fe 17. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000015ed8bfd 18. /build/src/Storages/StorageReplicatedMergeTree.cpp:2514: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x0000000015ec9aab 19. /build/src/Storages/StorageReplicatedMergeTree.cpp:2349: DB::StorageReplicatedMergeTree::executeLogEntry(DB::ReplicatedMergeTreeLogEntry&) @ 0x0000000015eba91b 20. /build/src/Storages/StorageReplicatedMergeTree.cpp:3876: bool std::__function::__policy_invoker&)>::__call_impl[abi:se190107])::$_1, bool (std::shared_ptr&)>>(std::__function::__policy_storage const*, std::shared_ptr&) @ 0x0000000015f9837e 21. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000165d6fc3 22. /build/src/Storages/StorageReplicatedMergeTree.cpp:3872: DB::StorageReplicatedMergeTree::processQueueEntry(std::shared_ptr) @ 0x0000000015efc18a 23. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001624c1b2 24. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000162f9c70 25. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x00000000162fa55a 26. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc6653 27. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000000fccc4c3 28. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc3d92 29. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fcca080 30. ? @ 0x00007fbc6213eac3 31. ? @ 0x00007fbc621d0850 (version 25.3.6.10636.altinitytest (altinity build)) 2025.07.28 11:57:17.443929 [ 17207 ] {4d26606c-db33-468d-9135-9ead6d5e9bf6} executeQuery: Code: 253. DB::Exception: Replica r1 of shard s1 of replicated database at /test/db/test_2 already exists. Replica host ID: '146b4357c08d:9000:19e16180-af7f-43fc-bc12-c25b4ab53332', current host ID: '146b4357c08d:9000:932220c1-2818-4fdc-87bc-a89a95125ed2'. (REPLICA_ALREADY_EXISTS) (version 25.3.6.10636.altinitytest (altinity build)) (from [::1]:42122) (comment: 00146_summing_merge_tree_nested_map.sql) (in query: CREATE DATABASE IF NOT EXISTS test_14er6jld ENGINE=Replicated('/test/db/test_2', 's1', 'r1') ), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.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&) @ 0x0000000013db5399 4. /build/src/Databases/DatabaseReplicated.cpp:494: DB::DatabaseReplicated::tryConnectToZooKeeperAndInitDatabase(DB::LoadingStrictnessLevel) @ 0x0000000013d91155 5. /build/src/Databases/DatabaseReplicated.cpp:735: DB::DatabaseReplicated::beforeLoadingMetadata(std::shared_ptr, DB::LoadingStrictnessLevel) @ 0x0000000013d954d4 6. /build/src/Databases/TablesLoader.cpp:57: DB::TablesLoader::loadTablesAsync(std::unordered_set, std::hash>, std::equal_to>, std::allocator>>) @ 0x000000001490e734 7. /build/src/Interpreters/InterpreterCreateQuery.cpp:383: DB::InterpreterCreateQuery::createDatabase(DB::ASTCreateQuery&) @ 0x00000000148e8e14 8. /build/src/Interpreters/InterpreterCreateQuery.cpp:2351: DB::InterpreterCreateQuery::execute() @ 0x0000000014905a3a 9. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88dc9 10. /build/src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x0000000014c8ca7b 11. /build/src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000001686da12 12. /build/src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x0000000016870807 13. /build/src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x0000000016907e99 14. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 15. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 16. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 17. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 18. ? @ 0x00007fbc6213eac3 19. ? @ 0x00007fbc621d0850 2025.07.28 11:57:17.454895 [ 17207 ] {4d26606c-db33-468d-9135-9ead6d5e9bf6} DynamicQueryHandler: Code: 253. DB::Exception: Replica r1 of shard s1 of replicated database at /test/db/test_2 already exists. Replica host ID: '146b4357c08d:9000:19e16180-af7f-43fc-bc12-c25b4ab53332', current host ID: '146b4357c08d:9000:932220c1-2818-4fdc-87bc-a89a95125ed2'. (REPLICA_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.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&) @ 0x0000000013db5399 4. /build/src/Databases/DatabaseReplicated.cpp:494: DB::DatabaseReplicated::tryConnectToZooKeeperAndInitDatabase(DB::LoadingStrictnessLevel) @ 0x0000000013d91155 5. /build/src/Databases/DatabaseReplicated.cpp:735: DB::DatabaseReplicated::beforeLoadingMetadata(std::shared_ptr, DB::LoadingStrictnessLevel) @ 0x0000000013d954d4 6. /build/src/Databases/TablesLoader.cpp:57: DB::TablesLoader::loadTablesAsync(std::unordered_set, std::hash>, std::equal_to>, std::allocator>>) @ 0x000000001490e734 7. /build/src/Interpreters/InterpreterCreateQuery.cpp:383: DB::InterpreterCreateQuery::createDatabase(DB::ASTCreateQuery&) @ 0x00000000148e8e14 8. /build/src/Interpreters/InterpreterCreateQuery.cpp:2351: DB::InterpreterCreateQuery::execute() @ 0x0000000014905a3a 9. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88dc9 10. /build/src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x0000000014c8ca7b 11. /build/src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000001686da12 12. /build/src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x0000000016870807 13. /build/src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x0000000016907e99 14. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 15. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 16. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 17. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 18. ? @ 0x00007fbc6213eac3 19. ? @ 0x00007fbc621d0850 (version 25.3.6.10636.altinitytest (altinity build)) 2025.07.28 11:57:17.594560 [ 4446 ] {9a1cf7a9-a23a-426d-896b-ff07e142afb0} executeQuery: Code: 253. DB::Exception: Replica r1 of shard s1 of replicated database at /test/db/test_2 already exists. Replica host ID: '146b4357c08d:9000:19e16180-af7f-43fc-bc12-c25b4ab53332', current host ID: '146b4357c08d:9000:827007bd-2a99-437c-971d-f10bf6c8d224'. (REPLICA_ALREADY_EXISTS) (version 25.3.6.10636.altinitytest (altinity build)) (from [::1]:42134) (comment: 03164_linestring_geometry.sql) (in query: CREATE DATABASE IF NOT EXISTS test_9yjbdqtm ENGINE=Replicated('/test/db/test_2', 's1', 'r1') ), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.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&) @ 0x0000000013db5399 4. /build/src/Databases/DatabaseReplicated.cpp:494: DB::DatabaseReplicated::tryConnectToZooKeeperAndInitDatabase(DB::LoadingStrictnessLevel) @ 0x0000000013d91155 5. /build/src/Databases/DatabaseReplicated.cpp:735: DB::DatabaseReplicated::beforeLoadingMetadata(std::shared_ptr, DB::LoadingStrictnessLevel) @ 0x0000000013d954d4 6. /build/src/Databases/TablesLoader.cpp:57: DB::TablesLoader::loadTablesAsync(std::unordered_set, std::hash>, std::equal_to>, std::allocator>>) @ 0x000000001490e734 7. /build/src/Interpreters/InterpreterCreateQuery.cpp:383: DB::InterpreterCreateQuery::createDatabase(DB::ASTCreateQuery&) @ 0x00000000148e8e14 8. /build/src/Interpreters/InterpreterCreateQuery.cpp:2351: DB::InterpreterCreateQuery::execute() @ 0x0000000014905a3a 9. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88dc9 10. /build/src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x0000000014c8ca7b 11. /build/src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000001686da12 12. /build/src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x0000000016870807 13. /build/src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x0000000016907e99 14. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 15. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 16. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 17. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 18. ? @ 0x00007fbc6213eac3 19. ? @ 0x00007fbc621d0850 2025.07.28 11:57:17.598561 [ 4446 ] {9a1cf7a9-a23a-426d-896b-ff07e142afb0} DynamicQueryHandler: Code: 253. DB::Exception: Replica r1 of shard s1 of replicated database at /test/db/test_2 already exists. Replica host ID: '146b4357c08d:9000:19e16180-af7f-43fc-bc12-c25b4ab53332', current host ID: '146b4357c08d:9000:827007bd-2a99-437c-971d-f10bf6c8d224'. (REPLICA_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.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&) @ 0x0000000013db5399 4. /build/src/Databases/DatabaseReplicated.cpp:494: DB::DatabaseReplicated::tryConnectToZooKeeperAndInitDatabase(DB::LoadingStrictnessLevel) @ 0x0000000013d91155 5. /build/src/Databases/DatabaseReplicated.cpp:735: DB::DatabaseReplicated::beforeLoadingMetadata(std::shared_ptr, DB::LoadingStrictnessLevel) @ 0x0000000013d954d4 6. /build/src/Databases/TablesLoader.cpp:57: DB::TablesLoader::loadTablesAsync(std::unordered_set, std::hash>, std::equal_to>, std::allocator>>) @ 0x000000001490e734 7. /build/src/Interpreters/InterpreterCreateQuery.cpp:383: DB::InterpreterCreateQuery::createDatabase(DB::ASTCreateQuery&) @ 0x00000000148e8e14 8. /build/src/Interpreters/InterpreterCreateQuery.cpp:2351: DB::InterpreterCreateQuery::execute() @ 0x0000000014905a3a 9. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88dc9 10. /build/src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x0000000014c8ca7b 11. /build/src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000001686da12 12. /build/src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x0000000016870807 13. /build/src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x0000000016907e99 14. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 15. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 16. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 17. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 18. ? @ 0x00007fbc6213eac3 19. ? @ 0x00007fbc621d0850 (version 25.3.6.10636.altinitytest (altinity build)) 2025.07.28 11:57:17.701693 [ 17287 ] {52390dd1-534f-4ec9-bf81-c6764571e046} executeQuery: Code: 253. DB::Exception: Replica r1 of shard s1 of replicated database at /test/db/test_2 already exists. Replica host ID: '146b4357c08d:9000:19e16180-af7f-43fc-bc12-c25b4ab53332', current host ID: '146b4357c08d:9000:8a1a45e2-caaf-4590-8d49-2bfaebec0d7d'. (REPLICA_ALREADY_EXISTS) (version 25.3.6.10636.altinitytest (altinity build)) (from [::1]:42142) (comment: 00327_summing_composite_nested.sql) (in query: CREATE DATABASE IF NOT EXISTS test_wedh7ah5 ENGINE=Replicated('/test/db/test_2', 's1', 'r1') ), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.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&) @ 0x0000000013db5399 4. /build/src/Databases/DatabaseReplicated.cpp:494: DB::DatabaseReplicated::tryConnectToZooKeeperAndInitDatabase(DB::LoadingStrictnessLevel) @ 0x0000000013d91155 5. /build/src/Databases/DatabaseReplicated.cpp:735: DB::DatabaseReplicated::beforeLoadingMetadata(std::shared_ptr, DB::LoadingStrictnessLevel) @ 0x0000000013d954d4 6. /build/src/Databases/TablesLoader.cpp:57: DB::TablesLoader::loadTablesAsync(std::unordered_set, std::hash>, std::equal_to>, std::allocator>>) @ 0x000000001490e734 7. /build/src/Interpreters/InterpreterCreateQuery.cpp:383: DB::InterpreterCreateQuery::createDatabase(DB::ASTCreateQuery&) @ 0x00000000148e8e14 8. /build/src/Interpreters/InterpreterCreateQuery.cpp:2351: DB::InterpreterCreateQuery::execute() @ 0x0000000014905a3a 9. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88dc9 10. /build/src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x0000000014c8ca7b 11. /build/src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000001686da12 12. /build/src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x0000000016870807 13. /build/src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x0000000016907e99 14. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 15. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 16. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 17. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 18. ? @ 0x00007fbc6213eac3 19. ? @ 0x00007fbc621d0850 2025.07.28 11:57:17.704844 [ 17287 ] {52390dd1-534f-4ec9-bf81-c6764571e046} DynamicQueryHandler: Code: 253. DB::Exception: Replica r1 of shard s1 of replicated database at /test/db/test_2 already exists. Replica host ID: '146b4357c08d:9000:19e16180-af7f-43fc-bc12-c25b4ab53332', current host ID: '146b4357c08d:9000:8a1a45e2-caaf-4590-8d49-2bfaebec0d7d'. (REPLICA_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.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&) @ 0x0000000013db5399 4. /build/src/Databases/DatabaseReplicated.cpp:494: DB::DatabaseReplicated::tryConnectToZooKeeperAndInitDatabase(DB::LoadingStrictnessLevel) @ 0x0000000013d91155 5. /build/src/Databases/DatabaseReplicated.cpp:735: DB::DatabaseReplicated::beforeLoadingMetadata(std::shared_ptr, DB::LoadingStrictnessLevel) @ 0x0000000013d954d4 6. /build/src/Databases/TablesLoader.cpp:57: DB::TablesLoader::loadTablesAsync(std::unordered_set, std::hash>, std::equal_to>, std::allocator>>) @ 0x000000001490e734 7. /build/src/Interpreters/InterpreterCreateQuery.cpp:383: DB::InterpreterCreateQuery::createDatabase(DB::ASTCreateQuery&) @ 0x00000000148e8e14 8. /build/src/Interpreters/InterpreterCreateQuery.cpp:2351: DB::InterpreterCreateQuery::execute() @ 0x0000000014905a3a 9. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88dc9 10. /build/src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x0000000014c8ca7b 11. /build/src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000001686da12 12. /build/src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x0000000016870807 13. /build/src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x0000000016907e99 14. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 15. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 16. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 17. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 18. ? @ 0x00007fbc6213eac3 19. ? @ 0x00007fbc621d0850 (version 25.3.6.10636.altinitytest (altinity build)) 2025.07.28 11:57:17.936656 [ 7625 ] {06edc6f7-a745-46ca-8c0c-dca178ec75c7} executeQuery: Code: 253. DB::Exception: Replica r1 of shard s1 of replicated database at /test/db/test_2 already exists. Replica host ID: '146b4357c08d:9000:19e16180-af7f-43fc-bc12-c25b4ab53332', current host ID: '146b4357c08d:9000:60510133-4de9-42aa-b5c8-62abb4da0703'. (REPLICA_ALREADY_EXISTS) (version 25.3.6.10636.altinitytest (altinity build)) (from [::1]:42168) (comment: 03214_count_distinct_null_key_memory_leak.sql) (in query: CREATE DATABASE IF NOT EXISTS test_4lal9bji ENGINE=Replicated('/test/db/test_2', 's1', 'r1') ), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.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&) @ 0x0000000013db5399 4. /build/src/Databases/DatabaseReplicated.cpp:494: DB::DatabaseReplicated::tryConnectToZooKeeperAndInitDatabase(DB::LoadingStrictnessLevel) @ 0x0000000013d91155 5. /build/src/Databases/DatabaseReplicated.cpp:735: DB::DatabaseReplicated::beforeLoadingMetadata(std::shared_ptr, DB::LoadingStrictnessLevel) @ 0x0000000013d954d4 6. /build/src/Databases/TablesLoader.cpp:57: DB::TablesLoader::loadTablesAsync(std::unordered_set, std::hash>, std::equal_to>, std::allocator>>) @ 0x000000001490e734 7. /build/src/Interpreters/InterpreterCreateQuery.cpp:383: DB::InterpreterCreateQuery::createDatabase(DB::ASTCreateQuery&) @ 0x00000000148e8e14 8. /build/src/Interpreters/InterpreterCreateQuery.cpp:2351: DB::InterpreterCreateQuery::execute() @ 0x0000000014905a3a 9. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88dc9 10. /build/src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x0000000014c8ca7b 11. /build/src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000001686da12 12. /build/src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x0000000016870807 13. /build/src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x0000000016907e99 14. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 15. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 16. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 17. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 18. ? @ 0x00007fbc6213eac3 19. ? @ 0x00007fbc621d0850 2025.07.28 11:57:17.953032 [ 7625 ] {06edc6f7-a745-46ca-8c0c-dca178ec75c7} DynamicQueryHandler: Code: 253. DB::Exception: Replica r1 of shard s1 of replicated database at /test/db/test_2 already exists. Replica host ID: '146b4357c08d:9000:19e16180-af7f-43fc-bc12-c25b4ab53332', current host ID: '146b4357c08d:9000:60510133-4de9-42aa-b5c8-62abb4da0703'. (REPLICA_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.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&) @ 0x0000000013db5399 4. /build/src/Databases/DatabaseReplicated.cpp:494: DB::DatabaseReplicated::tryConnectToZooKeeperAndInitDatabase(DB::LoadingStrictnessLevel) @ 0x0000000013d91155 5. /build/src/Databases/DatabaseReplicated.cpp:735: DB::DatabaseReplicated::beforeLoadingMetadata(std::shared_ptr, DB::LoadingStrictnessLevel) @ 0x0000000013d954d4 6. /build/src/Databases/TablesLoader.cpp:57: DB::TablesLoader::loadTablesAsync(std::unordered_set, std::hash>, std::equal_to>, std::allocator>>) @ 0x000000001490e734 7. /build/src/Interpreters/InterpreterCreateQuery.cpp:383: DB::InterpreterCreateQuery::createDatabase(DB::ASTCreateQuery&) @ 0x00000000148e8e14 8. /build/src/Interpreters/InterpreterCreateQuery.cpp:2351: DB::InterpreterCreateQuery::execute() @ 0x0000000014905a3a 9. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88dc9 10. /build/src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x0000000014c8ca7b 11. /build/src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000001686da12 12. /build/src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x0000000016870807 13. /build/src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x0000000016907e99 14. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 15. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 16. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 17. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 18. ? @ 0x00007fbc6213eac3 19. ? @ 0x00007fbc621d0850 (version 25.3.6.10636.altinitytest (altinity build)) 2025.07.28 11:57:18.035003 [ 17287 ] {992fffdf-a590-4e5b-b886-017ce6101993} executeQuery: Code: 253. DB::Exception: Replica r1 of shard s1 of replicated database at /test/db/test_2 already exists. Replica host ID: '146b4357c08d:9000:19e16180-af7f-43fc-bc12-c25b4ab53332', current host ID: '146b4357c08d:9000:506f761f-cc23-4a8c-9478-dbe105e45bb0'. (REPLICA_ALREADY_EXISTS) (version 25.3.6.10636.altinitytest (altinity build)) (from [::1]:42170) (comment: 02366_kql_extend.sql) (in query: CREATE DATABASE IF NOT EXISTS test_oc4o6kom ENGINE=Replicated('/test/db/test_2', 's1', 'r1') ), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.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&) @ 0x0000000013db5399 4. /build/src/Databases/DatabaseReplicated.cpp:494: DB::DatabaseReplicated::tryConnectToZooKeeperAndInitDatabase(DB::LoadingStrictnessLevel) @ 0x0000000013d91155 5. /build/src/Databases/DatabaseReplicated.cpp:735: DB::DatabaseReplicated::beforeLoadingMetadata(std::shared_ptr, DB::LoadingStrictnessLevel) @ 0x0000000013d954d4 6. /build/src/Databases/TablesLoader.cpp:57: DB::TablesLoader::loadTablesAsync(std::unordered_set, std::hash>, std::equal_to>, std::allocator>>) @ 0x000000001490e734 7. /build/src/Interpreters/InterpreterCreateQuery.cpp:383: DB::InterpreterCreateQuery::createDatabase(DB::ASTCreateQuery&) @ 0x00000000148e8e14 8. /build/src/Interpreters/InterpreterCreateQuery.cpp:2351: DB::InterpreterCreateQuery::execute() @ 0x0000000014905a3a 9. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88dc9 10. /build/src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x0000000014c8ca7b 11. /build/src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000001686da12 12. /build/src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x0000000016870807 13. /build/src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x0000000016907e99 14. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 15. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 16. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 17. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 18. ? @ 0x00007fbc6213eac3 19. ? @ 0x00007fbc621d0850 2025.07.28 11:57:18.068260 [ 17287 ] {992fffdf-a590-4e5b-b886-017ce6101993} DynamicQueryHandler: Code: 253. DB::Exception: Replica r1 of shard s1 of replicated database at /test/db/test_2 already exists. Replica host ID: '146b4357c08d:9000:19e16180-af7f-43fc-bc12-c25b4ab53332', current host ID: '146b4357c08d:9000:506f761f-cc23-4a8c-9478-dbe105e45bb0'. (REPLICA_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.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&) @ 0x0000000013db5399 4. /build/src/Databases/DatabaseReplicated.cpp:494: DB::DatabaseReplicated::tryConnectToZooKeeperAndInitDatabase(DB::LoadingStrictnessLevel) @ 0x0000000013d91155 5. /build/src/Databases/DatabaseReplicated.cpp:735: DB::DatabaseReplicated::beforeLoadingMetadata(std::shared_ptr, DB::LoadingStrictnessLevel) @ 0x0000000013d954d4 6. /build/src/Databases/TablesLoader.cpp:57: DB::TablesLoader::loadTablesAsync(std::unordered_set, std::hash>, std::equal_to>, std::allocator>>) @ 0x000000001490e734 7. /build/src/Interpreters/InterpreterCreateQuery.cpp:383: DB::InterpreterCreateQuery::createDatabase(DB::ASTCreateQuery&) @ 0x00000000148e8e14 8. /build/src/Interpreters/InterpreterCreateQuery.cpp:2351: DB::InterpreterCreateQuery::execute() @ 0x0000000014905a3a 9. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88dc9 10. /build/src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x0000000014c8ca7b 11. /build/src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000001686da12 12. /build/src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x0000000016870807 13. /build/src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x0000000016907e99 14. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 15. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 16. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 17. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 18. ? @ 0x00007fbc6213eac3 19. ? @ 0x00007fbc621d0850 (version 25.3.6.10636.altinitytest (altinity build)) 2025.07.28 11:57:18.137578 [ 17287 ] {4ce03310-b020-489f-b9bc-e5a287c83170} executeQuery: Code: 253. DB::Exception: Replica r1 of shard s1 of replicated database at /test/db/test_2 already exists. Replica host ID: '146b4357c08d:9000:19e16180-af7f-43fc-bc12-c25b4ab53332', current host ID: '146b4357c08d:9000:350099ba-c7fe-42e9-b09b-0909cecb0377'. (REPLICA_ALREADY_EXISTS) (version 25.3.6.10636.altinitytest (altinity build)) (from [::1]:42180) (comment: 01035_lc_empty_part_bug.sh) (in query: CREATE DATABASE IF NOT EXISTS test_59si6a0z ENGINE=Replicated('/test/db/test_2', 's1', 'r1') ), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.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&) @ 0x0000000013db5399 4. /build/src/Databases/DatabaseReplicated.cpp:494: DB::DatabaseReplicated::tryConnectToZooKeeperAndInitDatabase(DB::LoadingStrictnessLevel) @ 0x0000000013d91155 5. /build/src/Databases/DatabaseReplicated.cpp:735: DB::DatabaseReplicated::beforeLoadingMetadata(std::shared_ptr, DB::LoadingStrictnessLevel) @ 0x0000000013d954d4 6. /build/src/Databases/TablesLoader.cpp:57: DB::TablesLoader::loadTablesAsync(std::unordered_set, std::hash>, std::equal_to>, std::allocator>>) @ 0x000000001490e734 7. /build/src/Interpreters/InterpreterCreateQuery.cpp:383: DB::InterpreterCreateQuery::createDatabase(DB::ASTCreateQuery&) @ 0x00000000148e8e14 8. /build/src/Interpreters/InterpreterCreateQuery.cpp:2351: DB::InterpreterCreateQuery::execute() @ 0x0000000014905a3a 9. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88dc9 10. /build/src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x0000000014c8ca7b 11. /build/src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000001686da12 12. /build/src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x0000000016870807 13. /build/src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x0000000016907e99 14. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 15. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 16. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 17. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 18. ? @ 0x00007fbc6213eac3 19. ? @ 0x00007fbc621d0850 2025.07.28 11:57:18.144496 [ 17287 ] {4ce03310-b020-489f-b9bc-e5a287c83170} DynamicQueryHandler: Code: 253. DB::Exception: Replica r1 of shard s1 of replicated database at /test/db/test_2 already exists. Replica host ID: '146b4357c08d:9000:19e16180-af7f-43fc-bc12-c25b4ab53332', current host ID: '146b4357c08d:9000:350099ba-c7fe-42e9-b09b-0909cecb0377'. (REPLICA_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.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&) @ 0x0000000013db5399 4. /build/src/Databases/DatabaseReplicated.cpp:494: DB::DatabaseReplicated::tryConnectToZooKeeperAndInitDatabase(DB::LoadingStrictnessLevel) @ 0x0000000013d91155 5. /build/src/Databases/DatabaseReplicated.cpp:735: DB::DatabaseReplicated::beforeLoadingMetadata(std::shared_ptr, DB::LoadingStrictnessLevel) @ 0x0000000013d954d4 6. /build/src/Databases/TablesLoader.cpp:57: DB::TablesLoader::loadTablesAsync(std::unordered_set, std::hash>, std::equal_to>, std::allocator>>) @ 0x000000001490e734 7. /build/src/Interpreters/InterpreterCreateQuery.cpp:383: DB::InterpreterCreateQuery::createDatabase(DB::ASTCreateQuery&) @ 0x00000000148e8e14 8. /build/src/Interpreters/InterpreterCreateQuery.cpp:2351: DB::InterpreterCreateQuery::execute() @ 0x0000000014905a3a 9. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88dc9 10. /build/src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x0000000014c8ca7b 11. /build/src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000001686da12 12. /build/src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x0000000016870807 13. /build/src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x0000000016907e99 14. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 15. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 16. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 17. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 18. ? @ 0x00007fbc6213eac3 19. ? @ 0x00007fbc621d0850 (version 25.3.6.10636.altinitytest (altinity build)) 2025.07.28 11:57:18.187186 [ 3974 ] {} test_13.rmt2 (7f9b740d-015c-470e-8cc6-8ba33be0dc63): auto DB::StorageReplicatedMergeTree::processQueueEntry(ReplicatedMergeTreeQueue::SelectedEntryPtr)::(anonymous class)::operator()(LogEntryPtr &) const: Code: 86. DB::HTTPException: Received error from remote server http://146b4357c08d:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Ftest%2F01165%2Ftest_13%2Frmt%2Freplicas%2F1&part=20250728_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.6.10636.altinitytest (altinity build)) '. (RECEIVED_ERROR_FROM_REMOTE_IO_SERVER), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.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 const&, int&&, String const&, unsigned long&&, String const&) @ 0x000000000feda8d9 4. /build/src/IO/HTTPCommon.cpp:104: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x000000000feda6e2 5. /build/src/IO/HTTPCommon.cpp:93: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x000000000feda537 6. /build/src/IO/ReadWriteBufferFromHTTP.cpp:277: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x000000001184a4c4 7. /build/src/IO/ReadWriteBufferFromHTTP.cpp:285: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x000000001184a615 8. /build/src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x000000001184ae59 9. /build/src/IO/ReadWriteBufferFromHTTP.cpp:472: void std::__function::__policy_invoker::__call_impl[abi:se190107]>(std::__function::__policy_storage const*) @ 0x000000001184cedd 10. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001184858b 11. /build/src/IO/ReadWriteBufferFromHTTP.cpp:465: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x000000001184bf0b 12. /build/src/IO/ReadBuffer.h:60: DB::ReadBuffer::next() @ 0x000000000a148c7b 13. /build/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) @ 0x0000000011849fb2 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]>&)>&, 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&) @ 0x0000000011841980 15. /build/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) @ 0x000000001621208e 16. /build/src/Storages/StorageReplicatedMergeTree.cpp:5228: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl[abi:se190107] const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000015f9a5fe 17. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000015ed8bfd 18. /build/src/Storages/StorageReplicatedMergeTree.cpp:2514: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x0000000015ec9aab 19. /build/src/Storages/StorageReplicatedMergeTree.cpp:2349: DB::StorageReplicatedMergeTree::executeLogEntry(DB::ReplicatedMergeTreeLogEntry&) @ 0x0000000015eba91b 20. /build/src/Storages/StorageReplicatedMergeTree.cpp:3876: bool std::__function::__policy_invoker&)>::__call_impl[abi:se190107])::$_1, bool (std::shared_ptr&)>>(std::__function::__policy_storage const*, std::shared_ptr&) @ 0x0000000015f9837e 21. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000165d6fc3 22. /build/src/Storages/StorageReplicatedMergeTree.cpp:3872: DB::StorageReplicatedMergeTree::processQueueEntry(std::shared_ptr) @ 0x0000000015efc18a 23. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001624c1b2 24. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000162f9c70 25. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x00000000162fa55a 26. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc6653 27. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000000fccc4c3 28. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc3d92 29. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fcca080 30. ? @ 0x00007fbc6213eac3 31. ? @ 0x00007fbc621d0850 (version 25.3.6.10636.altinitytest (altinity build)) 2025.07.28 11:57:18.255707 [ 7625 ] {14810fb1-434c-40cf-8676-3a06ae455bb8} executeQuery: Code: 253. DB::Exception: Replica r1 of shard s1 of replicated database at /test/db/test_2 already exists. Replica host ID: '146b4357c08d:9000:19e16180-af7f-43fc-bc12-c25b4ab53332', current host ID: '146b4357c08d:9000:d850f717-2b08-4904-9f55-eff6601a10c6'. (REPLICA_ALREADY_EXISTS) (version 25.3.6.10636.altinitytest (altinity build)) (from [::1]:42182) (comment: 00399_group_uniq_array_date_datetime.sql) (in query: CREATE DATABASE IF NOT EXISTS test_m6lyi542 ENGINE=Replicated('/test/db/test_2', 's1', 'r1') ), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.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&) @ 0x0000000013db5399 4. /build/src/Databases/DatabaseReplicated.cpp:494: DB::DatabaseReplicated::tryConnectToZooKeeperAndInitDatabase(DB::LoadingStrictnessLevel) @ 0x0000000013d91155 5. /build/src/Databases/DatabaseReplicated.cpp:735: DB::DatabaseReplicated::beforeLoadingMetadata(std::shared_ptr, DB::LoadingStrictnessLevel) @ 0x0000000013d954d4 6. /build/src/Databases/TablesLoader.cpp:57: DB::TablesLoader::loadTablesAsync(std::unordered_set, std::hash>, std::equal_to>, std::allocator>>) @ 0x000000001490e734 7. /build/src/Interpreters/InterpreterCreateQuery.cpp:383: DB::InterpreterCreateQuery::createDatabase(DB::ASTCreateQuery&) @ 0x00000000148e8e14 8. /build/src/Interpreters/InterpreterCreateQuery.cpp:2351: DB::InterpreterCreateQuery::execute() @ 0x0000000014905a3a 9. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88dc9 10. /build/src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x0000000014c8ca7b 11. /build/src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000001686da12 12. /build/src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x0000000016870807 13. /build/src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x0000000016907e99 14. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 15. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 16. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 17. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 18. ? @ 0x00007fbc6213eac3 19. ? @ 0x00007fbc621d0850 2025.07.28 11:57:18.257417 [ 7625 ] {14810fb1-434c-40cf-8676-3a06ae455bb8} DynamicQueryHandler: Code: 253. DB::Exception: Replica r1 of shard s1 of replicated database at /test/db/test_2 already exists. Replica host ID: '146b4357c08d:9000:19e16180-af7f-43fc-bc12-c25b4ab53332', current host ID: '146b4357c08d:9000:d850f717-2b08-4904-9f55-eff6601a10c6'. (REPLICA_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.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&) @ 0x0000000013db5399 4. /build/src/Databases/DatabaseReplicated.cpp:494: DB::DatabaseReplicated::tryConnectToZooKeeperAndInitDatabase(DB::LoadingStrictnessLevel) @ 0x0000000013d91155 5. /build/src/Databases/DatabaseReplicated.cpp:735: DB::DatabaseReplicated::beforeLoadingMetadata(std::shared_ptr, DB::LoadingStrictnessLevel) @ 0x0000000013d954d4 6. /build/src/Databases/TablesLoader.cpp:57: DB::TablesLoader::loadTablesAsync(std::unordered_set, std::hash>, std::equal_to>, std::allocator>>) @ 0x000000001490e734 7. /build/src/Interpreters/InterpreterCreateQuery.cpp:383: DB::InterpreterCreateQuery::createDatabase(DB::ASTCreateQuery&) @ 0x00000000148e8e14 8. /build/src/Interpreters/InterpreterCreateQuery.cpp:2351: DB::InterpreterCreateQuery::execute() @ 0x0000000014905a3a 9. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88dc9 10. /build/src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x0000000014c8ca7b 11. /build/src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000001686da12 12. /build/src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x0000000016870807 13. /build/src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x0000000016907e99 14. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 15. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 16. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 17. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 18. ? @ 0x00007fbc6213eac3 19. ? @ 0x00007fbc621d0850 (version 25.3.6.10636.altinitytest (altinity build)) 2025.07.28 11:57:18.350404 [ 7625 ] {9f5a78f2-e9e0-4c6a-938d-41268eb28227} executeQuery: Code: 253. DB::Exception: Replica r1 of shard s1 of replicated database at /test/db/test_2 already exists. Replica host ID: '146b4357c08d:9000:19e16180-af7f-43fc-bc12-c25b4ab53332', current host ID: '146b4357c08d:9000:06a8af33-d982-4b19-bc87-28b02405da01'. (REPLICA_ALREADY_EXISTS) (version 25.3.6.10636.altinitytest (altinity build)) (from [::1]:42190) (comment: 02483_capnp_decimals.sh) (in query: CREATE DATABASE IF NOT EXISTS test_bgm36enf ENGINE=Replicated('/test/db/test_2', 's1', 'r1') ), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.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&) @ 0x0000000013db5399 4. /build/src/Databases/DatabaseReplicated.cpp:494: DB::DatabaseReplicated::tryConnectToZooKeeperAndInitDatabase(DB::LoadingStrictnessLevel) @ 0x0000000013d91155 5. /build/src/Databases/DatabaseReplicated.cpp:735: DB::DatabaseReplicated::beforeLoadingMetadata(std::shared_ptr, DB::LoadingStrictnessLevel) @ 0x0000000013d954d4 6. /build/src/Databases/TablesLoader.cpp:57: DB::TablesLoader::loadTablesAsync(std::unordered_set, std::hash>, std::equal_to>, std::allocator>>) @ 0x000000001490e734 7. /build/src/Interpreters/InterpreterCreateQuery.cpp:383: DB::InterpreterCreateQuery::createDatabase(DB::ASTCreateQuery&) @ 0x00000000148e8e14 8. /build/src/Interpreters/InterpreterCreateQuery.cpp:2351: DB::InterpreterCreateQuery::execute() @ 0x0000000014905a3a 9. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88dc9 10. /build/src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x0000000014c8ca7b 11. /build/src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000001686da12 12. /build/src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x0000000016870807 13. /build/src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x0000000016907e99 14. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 15. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 16. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 17. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 18. ? @ 0x00007fbc6213eac3 19. ? @ 0x00007fbc621d0850 2025.07.28 11:57:18.367878 [ 7625 ] {9f5a78f2-e9e0-4c6a-938d-41268eb28227} DynamicQueryHandler: Code: 253. DB::Exception: Replica r1 of shard s1 of replicated database at /test/db/test_2 already exists. Replica host ID: '146b4357c08d:9000:19e16180-af7f-43fc-bc12-c25b4ab53332', current host ID: '146b4357c08d:9000:06a8af33-d982-4b19-bc87-28b02405da01'. (REPLICA_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.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&) @ 0x0000000013db5399 4. /build/src/Databases/DatabaseReplicated.cpp:494: DB::DatabaseReplicated::tryConnectToZooKeeperAndInitDatabase(DB::LoadingStrictnessLevel) @ 0x0000000013d91155 5. /build/src/Databases/DatabaseReplicated.cpp:735: DB::DatabaseReplicated::beforeLoadingMetadata(std::shared_ptr, DB::LoadingStrictnessLevel) @ 0x0000000013d954d4 6. /build/src/Databases/TablesLoader.cpp:57: DB::TablesLoader::loadTablesAsync(std::unordered_set, std::hash>, std::equal_to>, std::allocator>>) @ 0x000000001490e734 7. /build/src/Interpreters/InterpreterCreateQuery.cpp:383: DB::InterpreterCreateQuery::createDatabase(DB::ASTCreateQuery&) @ 0x00000000148e8e14 8. /build/src/Interpreters/InterpreterCreateQuery.cpp:2351: DB::InterpreterCreateQuery::execute() @ 0x0000000014905a3a 9. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88dc9 10. /build/src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x0000000014c8ca7b 11. /build/src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000001686da12 12. /build/src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x0000000016870807 13. /build/src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x0000000016907e99 14. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 15. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 16. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 17. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 18. ? @ 0x00007fbc6213eac3 19. ? @ 0x00007fbc621d0850 (version 25.3.6.10636.altinitytest (altinity build)) 2025.07.28 11:57:18.447670 [ 4446 ] {2b1e6ea0-37b0-4677-855b-9a14d10d1dc6} executeQuery: Code: 253. DB::Exception: Replica r1 of shard s1 of replicated database at /test/db/test_2 already exists. Replica host ID: '146b4357c08d:9000:19e16180-af7f-43fc-bc12-c25b4ab53332', current host ID: '146b4357c08d:9000:34399821-e402-4661-b383-c2a24be0250a'. (REPLICA_ALREADY_EXISTS) (version 25.3.6.10636.altinitytest (altinity build)) (from [::1]:42210) (comment: 03128_system_unload_primary_key.sql) (in query: CREATE DATABASE IF NOT EXISTS test_phfzi4wg ENGINE=Replicated('/test/db/test_2', 's1', 'r1') ), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.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&) @ 0x0000000013db5399 4. /build/src/Databases/DatabaseReplicated.cpp:494: DB::DatabaseReplicated::tryConnectToZooKeeperAndInitDatabase(DB::LoadingStrictnessLevel) @ 0x0000000013d91155 5. /build/src/Databases/DatabaseReplicated.cpp:735: DB::DatabaseReplicated::beforeLoadingMetadata(std::shared_ptr, DB::LoadingStrictnessLevel) @ 0x0000000013d954d4 6. /build/src/Databases/TablesLoader.cpp:57: DB::TablesLoader::loadTablesAsync(std::unordered_set, std::hash>, std::equal_to>, std::allocator>>) @ 0x000000001490e734 7. /build/src/Interpreters/InterpreterCreateQuery.cpp:383: DB::InterpreterCreateQuery::createDatabase(DB::ASTCreateQuery&) @ 0x00000000148e8e14 8. /build/src/Interpreters/InterpreterCreateQuery.cpp:2351: DB::InterpreterCreateQuery::execute() @ 0x0000000014905a3a 9. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88dc9 10. /build/src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x0000000014c8ca7b 11. /build/src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000001686da12 12. /build/src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x0000000016870807 13. /build/src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x0000000016907e99 14. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 15. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 16. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 17. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 18. ? @ 0x00007fbc6213eac3 19. ? @ 0x00007fbc621d0850 2025.07.28 11:57:18.449879 [ 4446 ] {2b1e6ea0-37b0-4677-855b-9a14d10d1dc6} DynamicQueryHandler: Code: 253. DB::Exception: Replica r1 of shard s1 of replicated database at /test/db/test_2 already exists. Replica host ID: '146b4357c08d:9000:19e16180-af7f-43fc-bc12-c25b4ab53332', current host ID: '146b4357c08d:9000:34399821-e402-4661-b383-c2a24be0250a'. (REPLICA_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.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&) @ 0x0000000013db5399 4. /build/src/Databases/DatabaseReplicated.cpp:494: DB::DatabaseReplicated::tryConnectToZooKeeperAndInitDatabase(DB::LoadingStrictnessLevel) @ 0x0000000013d91155 5. /build/src/Databases/DatabaseReplicated.cpp:735: DB::DatabaseReplicated::beforeLoadingMetadata(std::shared_ptr, DB::LoadingStrictnessLevel) @ 0x0000000013d954d4 6. /build/src/Databases/TablesLoader.cpp:57: DB::TablesLoader::loadTablesAsync(std::unordered_set, std::hash>, std::equal_to>, std::allocator>>) @ 0x000000001490e734 7. /build/src/Interpreters/InterpreterCreateQuery.cpp:383: DB::InterpreterCreateQuery::createDatabase(DB::ASTCreateQuery&) @ 0x00000000148e8e14 8. /build/src/Interpreters/InterpreterCreateQuery.cpp:2351: DB::InterpreterCreateQuery::execute() @ 0x0000000014905a3a 9. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88dc9 10. /build/src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x0000000014c8ca7b 11. /build/src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000001686da12 12. /build/src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x0000000016870807 13. /build/src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x0000000016907e99 14. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 15. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 16. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 17. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 18. ? @ 0x00007fbc6213eac3 19. ? @ 0x00007fbc621d0850 (version 25.3.6.10636.altinitytest (altinity build)) 2025.07.28 11:57:18.527013 [ 3967 ] {} test_13.rmt2 (7f9b740d-015c-470e-8cc6-8ba33be0dc63): auto DB::StorageReplicatedMergeTree::processQueueEntry(ReplicatedMergeTreeQueue::SelectedEntryPtr)::(anonymous class)::operator()(LogEntryPtr &) const: Code: 86. DB::HTTPException: Received error from remote server http://146b4357c08d:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Ftest%2F01165%2Ftest_13%2Frmt%2Freplicas%2F1&part=20250728_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.6.10636.altinitytest (altinity build)) '. (RECEIVED_ERROR_FROM_REMOTE_IO_SERVER), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.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 const&, int&&, String const&, unsigned long&&, String const&) @ 0x000000000feda8d9 4. /build/src/IO/HTTPCommon.cpp:104: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x000000000feda6e2 5. /build/src/IO/HTTPCommon.cpp:93: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x000000000feda537 6. /build/src/IO/ReadWriteBufferFromHTTP.cpp:277: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x000000001184a4c4 7. /build/src/IO/ReadWriteBufferFromHTTP.cpp:285: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x000000001184a615 8. /build/src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x000000001184ae59 9. /build/src/IO/ReadWriteBufferFromHTTP.cpp:472: void std::__function::__policy_invoker::__call_impl[abi:se190107]>(std::__function::__policy_storage const*) @ 0x000000001184cedd 10. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001184858b 11. /build/src/IO/ReadWriteBufferFromHTTP.cpp:465: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x000000001184bf0b 12. /build/src/IO/ReadBuffer.h:60: DB::ReadBuffer::next() @ 0x000000000a148c7b 13. /build/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) @ 0x0000000011849fb2 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]>&)>&, 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&) @ 0x0000000011841980 15. /build/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) @ 0x000000001621208e 16. /build/src/Storages/StorageReplicatedMergeTree.cpp:5228: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl[abi:se190107] const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000015f9a5fe 17. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000015ed8bfd 18. /build/src/Storages/StorageReplicatedMergeTree.cpp:2514: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x0000000015ec9aab 19. /build/src/Storages/StorageReplicatedMergeTree.cpp:2349: DB::StorageReplicatedMergeTree::executeLogEntry(DB::ReplicatedMergeTreeLogEntry&) @ 0x0000000015eba91b 20. /build/src/Storages/StorageReplicatedMergeTree.cpp:3876: bool std::__function::__policy_invoker&)>::__call_impl[abi:se190107])::$_1, bool (std::shared_ptr&)>>(std::__function::__policy_storage const*, std::shared_ptr&) @ 0x0000000015f9837e 21. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000165d6fc3 22. /build/src/Storages/StorageReplicatedMergeTree.cpp:3872: DB::StorageReplicatedMergeTree::processQueueEntry(std::shared_ptr) @ 0x0000000015efc18a 23. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001624c1b2 24. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000162f9c70 25. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x00000000162fa55a 26. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc6653 27. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000000fccc4c3 28. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc3d92 29. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fcca080 30. ? @ 0x00007fbc6213eac3 31. ? @ 0x00007fbc621d0850 (version 25.3.6.10636.altinitytest (altinity build)) 2025.07.28 11:57:18.543272 [ 7625 ] {f09ec55e-5210-4035-b1ec-1466dee93d0d} executeQuery: Code: 253. DB::Exception: Replica r1 of shard s1 of replicated database at /test/db/test_2 already exists. Replica host ID: '146b4357c08d:9000:19e16180-af7f-43fc-bc12-c25b4ab53332', current host ID: '146b4357c08d:9000:6e677243-b8a8-494f-99b8-20d7f803501f'. (REPLICA_ALREADY_EXISTS) (version 25.3.6.10636.altinitytest (altinity build)) (from [::1]:42240) (comment: 02181_format_from_file_extension_local.sh) (in query: CREATE DATABASE IF NOT EXISTS test_ihkr46ov ENGINE=Replicated('/test/db/test_2', 's1', 'r1') ), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.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&) @ 0x0000000013db5399 4. /build/src/Databases/DatabaseReplicated.cpp:494: DB::DatabaseReplicated::tryConnectToZooKeeperAndInitDatabase(DB::LoadingStrictnessLevel) @ 0x0000000013d91155 5. /build/src/Databases/DatabaseReplicated.cpp:735: DB::DatabaseReplicated::beforeLoadingMetadata(std::shared_ptr, DB::LoadingStrictnessLevel) @ 0x0000000013d954d4 6. /build/src/Databases/TablesLoader.cpp:57: DB::TablesLoader::loadTablesAsync(std::unordered_set, std::hash>, std::equal_to>, std::allocator>>) @ 0x000000001490e734 7. /build/src/Interpreters/InterpreterCreateQuery.cpp:383: DB::InterpreterCreateQuery::createDatabase(DB::ASTCreateQuery&) @ 0x00000000148e8e14 8. /build/src/Interpreters/InterpreterCreateQuery.cpp:2351: DB::InterpreterCreateQuery::execute() @ 0x0000000014905a3a 9. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88dc9 10. /build/src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x0000000014c8ca7b 11. /build/src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000001686da12 12. /build/src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x0000000016870807 13. /build/src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x0000000016907e99 14. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 15. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 16. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 17. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 18. ? @ 0x00007fbc6213eac3 19. ? @ 0x00007fbc621d0850 2025.07.28 11:57:18.545143 [ 7625 ] {f09ec55e-5210-4035-b1ec-1466dee93d0d} DynamicQueryHandler: Code: 253. DB::Exception: Replica r1 of shard s1 of replicated database at /test/db/test_2 already exists. Replica host ID: '146b4357c08d:9000:19e16180-af7f-43fc-bc12-c25b4ab53332', current host ID: '146b4357c08d:9000:6e677243-b8a8-494f-99b8-20d7f803501f'. (REPLICA_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.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&) @ 0x0000000013db5399 4. /build/src/Databases/DatabaseReplicated.cpp:494: DB::DatabaseReplicated::tryConnectToZooKeeperAndInitDatabase(DB::LoadingStrictnessLevel) @ 0x0000000013d91155 5. /build/src/Databases/DatabaseReplicated.cpp:735: DB::DatabaseReplicated::beforeLoadingMetadata(std::shared_ptr, DB::LoadingStrictnessLevel) @ 0x0000000013d954d4 6. /build/src/Databases/TablesLoader.cpp:57: DB::TablesLoader::loadTablesAsync(std::unordered_set, std::hash>, std::equal_to>, std::allocator>>) @ 0x000000001490e734 7. /build/src/Interpreters/InterpreterCreateQuery.cpp:383: DB::InterpreterCreateQuery::createDatabase(DB::ASTCreateQuery&) @ 0x00000000148e8e14 8. /build/src/Interpreters/InterpreterCreateQuery.cpp:2351: DB::InterpreterCreateQuery::execute() @ 0x0000000014905a3a 9. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88dc9 10. /build/src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x0000000014c8ca7b 11. /build/src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000001686da12 12. /build/src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x0000000016870807 13. /build/src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x0000000016907e99 14. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 15. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 16. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 17. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 18. ? @ 0x00007fbc6213eac3 19. ? @ 0x00007fbc621d0850 (version 25.3.6.10636.altinitytest (altinity build)) 2025.07.28 11:57:18.662480 [ 17232 ] {21cec60c-2588-402d-a7bb-2024db910e85} executeQuery: Code: 253. DB::Exception: Replica r1 of shard s1 of replicated database at /test/db/test_2 already exists. Replica host ID: '146b4357c08d:9000:19e16180-af7f-43fc-bc12-c25b4ab53332', current host ID: '146b4357c08d:9000:5f81a33f-00a9-4f1d-92a3-52a05b35db20'. (REPLICA_ALREADY_EXISTS) (version 25.3.6.10636.altinitytest (altinity build)) (from [::1]:42256) (comment: 02572_system_logs_materialized_views_ignore_errors.sql) (in query: CREATE DATABASE IF NOT EXISTS test_wed2jmi9 ENGINE=Replicated('/test/db/test_2', 's1', 'r1') ), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.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&) @ 0x0000000013db5399 4. /build/src/Databases/DatabaseReplicated.cpp:494: DB::DatabaseReplicated::tryConnectToZooKeeperAndInitDatabase(DB::LoadingStrictnessLevel) @ 0x0000000013d91155 5. /build/src/Databases/DatabaseReplicated.cpp:735: DB::DatabaseReplicated::beforeLoadingMetadata(std::shared_ptr, DB::LoadingStrictnessLevel) @ 0x0000000013d954d4 6. /build/src/Databases/TablesLoader.cpp:57: DB::TablesLoader::loadTablesAsync(std::unordered_set, std::hash>, std::equal_to>, std::allocator>>) @ 0x000000001490e734 7. /build/src/Interpreters/InterpreterCreateQuery.cpp:383: DB::InterpreterCreateQuery::createDatabase(DB::ASTCreateQuery&) @ 0x00000000148e8e14 8. /build/src/Interpreters/InterpreterCreateQuery.cpp:2351: DB::InterpreterCreateQuery::execute() @ 0x0000000014905a3a 9. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88dc9 10. /build/src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x0000000014c8ca7b 11. /build/src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000001686da12 12. /build/src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x0000000016870807 13. /build/src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x0000000016907e99 14. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 15. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 16. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 17. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 18. ? @ 0x00007fbc6213eac3 19. ? @ 0x00007fbc621d0850 2025.07.28 11:57:18.687857 [ 17232 ] {21cec60c-2588-402d-a7bb-2024db910e85} DynamicQueryHandler: Code: 253. DB::Exception: Replica r1 of shard s1 of replicated database at /test/db/test_2 already exists. Replica host ID: '146b4357c08d:9000:19e16180-af7f-43fc-bc12-c25b4ab53332', current host ID: '146b4357c08d:9000:5f81a33f-00a9-4f1d-92a3-52a05b35db20'. (REPLICA_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.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&) @ 0x0000000013db5399 4. /build/src/Databases/DatabaseReplicated.cpp:494: DB::DatabaseReplicated::tryConnectToZooKeeperAndInitDatabase(DB::LoadingStrictnessLevel) @ 0x0000000013d91155 5. /build/src/Databases/DatabaseReplicated.cpp:735: DB::DatabaseReplicated::beforeLoadingMetadata(std::shared_ptr, DB::LoadingStrictnessLevel) @ 0x0000000013d954d4 6. /build/src/Databases/TablesLoader.cpp:57: DB::TablesLoader::loadTablesAsync(std::unordered_set, std::hash>, std::equal_to>, std::allocator>>) @ 0x000000001490e734 7. /build/src/Interpreters/InterpreterCreateQuery.cpp:383: DB::InterpreterCreateQuery::createDatabase(DB::ASTCreateQuery&) @ 0x00000000148e8e14 8. /build/src/Interpreters/InterpreterCreateQuery.cpp:2351: DB::InterpreterCreateQuery::execute() @ 0x0000000014905a3a 9. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88dc9 10. /build/src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x0000000014c8ca7b 11. /build/src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000001686da12 12. /build/src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x0000000016870807 13. /build/src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x0000000016907e99 14. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 15. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 16. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 17. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 18. ? @ 0x00007fbc6213eac3 19. ? @ 0x00007fbc621d0850 (version 25.3.6.10636.altinitytest (altinity build)) 2025.07.28 11:57:18.877422 [ 3287 ] {47f19b7b-d3c7-48a2-bc3f-3b07152ece36} executeQuery: Code: 253. DB::Exception: Replica r1 of shard s1 of replicated database at /test/db/test_2 already exists. Replica host ID: '146b4357c08d:9000:19e16180-af7f-43fc-bc12-c25b4ab53332', current host ID: '146b4357c08d:9000:984c9d53-8049-42b1-a332-5d02eaa8a236'. (REPLICA_ALREADY_EXISTS) (version 25.3.6.10636.altinitytest (altinity build)) (from [::1]:42260) (comment: 02015_column_default_dict_get_identifier.sql) (in query: CREATE DATABASE IF NOT EXISTS test_gqnlfw8q ENGINE=Replicated('/test/db/test_2', 's1', 'r1') ), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.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&) @ 0x0000000013db5399 4. /build/src/Databases/DatabaseReplicated.cpp:494: DB::DatabaseReplicated::tryConnectToZooKeeperAndInitDatabase(DB::LoadingStrictnessLevel) @ 0x0000000013d91155 5. /build/src/Databases/DatabaseReplicated.cpp:735: DB::DatabaseReplicated::beforeLoadingMetadata(std::shared_ptr, DB::LoadingStrictnessLevel) @ 0x0000000013d954d4 6. /build/src/Databases/TablesLoader.cpp:57: DB::TablesLoader::loadTablesAsync(std::unordered_set, std::hash>, std::equal_to>, std::allocator>>) @ 0x000000001490e734 7. /build/src/Interpreters/InterpreterCreateQuery.cpp:383: DB::InterpreterCreateQuery::createDatabase(DB::ASTCreateQuery&) @ 0x00000000148e8e14 8. /build/src/Interpreters/InterpreterCreateQuery.cpp:2351: DB::InterpreterCreateQuery::execute() @ 0x0000000014905a3a 9. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88dc9 10. /build/src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x0000000014c8ca7b 11. /build/src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000001686da12 12. /build/src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x0000000016870807 13. /build/src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x0000000016907e99 14. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 15. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 16. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 17. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 18. ? @ 0x00007fbc6213eac3 19. ? @ 0x00007fbc621d0850 2025.07.28 11:57:18.890304 [ 3287 ] {47f19b7b-d3c7-48a2-bc3f-3b07152ece36} DynamicQueryHandler: Code: 253. DB::Exception: Replica r1 of shard s1 of replicated database at /test/db/test_2 already exists. Replica host ID: '146b4357c08d:9000:19e16180-af7f-43fc-bc12-c25b4ab53332', current host ID: '146b4357c08d:9000:984c9d53-8049-42b1-a332-5d02eaa8a236'. (REPLICA_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.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&) @ 0x0000000013db5399 4. /build/src/Databases/DatabaseReplicated.cpp:494: DB::DatabaseReplicated::tryConnectToZooKeeperAndInitDatabase(DB::LoadingStrictnessLevel) @ 0x0000000013d91155 5. /build/src/Databases/DatabaseReplicated.cpp:735: DB::DatabaseReplicated::beforeLoadingMetadata(std::shared_ptr, DB::LoadingStrictnessLevel) @ 0x0000000013d954d4 6. /build/src/Databases/TablesLoader.cpp:57: DB::TablesLoader::loadTablesAsync(std::unordered_set, std::hash>, std::equal_to>, std::allocator>>) @ 0x000000001490e734 7. /build/src/Interpreters/InterpreterCreateQuery.cpp:383: DB::InterpreterCreateQuery::createDatabase(DB::ASTCreateQuery&) @ 0x00000000148e8e14 8. /build/src/Interpreters/InterpreterCreateQuery.cpp:2351: DB::InterpreterCreateQuery::execute() @ 0x0000000014905a3a 9. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88dc9 10. /build/src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x0000000014c8ca7b 11. /build/src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000001686da12 12. /build/src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x0000000016870807 13. /build/src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x0000000016907e99 14. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 15. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 16. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 17. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 18. ? @ 0x00007fbc6213eac3 19. ? @ 0x00007fbc621d0850 (version 25.3.6.10636.altinitytest (altinity build)) 2025.07.28 11:57:19.035551 [ 17321 ] {30e6e8e1-2e4e-4645-8b58-72d74406d85e} executeQuery: Code: 253. DB::Exception: Replica r1 of shard s1 of replicated database at /test/db/test_2 already exists. Replica host ID: '146b4357c08d:9000:19e16180-af7f-43fc-bc12-c25b4ab53332', current host ID: '146b4357c08d:9000:96de0d89-92c2-445b-919b-65d42a702b49'. (REPLICA_ALREADY_EXISTS) (version 25.3.6.10636.altinitytest (altinity build)) (from [::1]:42264) (comment: 00143_transform_non_const_default.sql) (in query: CREATE DATABASE IF NOT EXISTS test_sdwoxy0e ENGINE=Replicated('/test/db/test_2', 's1', 'r1') ), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.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&) @ 0x0000000013db5399 4. /build/src/Databases/DatabaseReplicated.cpp:494: DB::DatabaseReplicated::tryConnectToZooKeeperAndInitDatabase(DB::LoadingStrictnessLevel) @ 0x0000000013d91155 5. /build/src/Databases/DatabaseReplicated.cpp:735: DB::DatabaseReplicated::beforeLoadingMetadata(std::shared_ptr, DB::LoadingStrictnessLevel) @ 0x0000000013d954d4 6. /build/src/Databases/TablesLoader.cpp:57: DB::TablesLoader::loadTablesAsync(std::unordered_set, std::hash>, std::equal_to>, std::allocator>>) @ 0x000000001490e734 7. /build/src/Interpreters/InterpreterCreateQuery.cpp:383: DB::InterpreterCreateQuery::createDatabase(DB::ASTCreateQuery&) @ 0x00000000148e8e14 8. /build/src/Interpreters/InterpreterCreateQuery.cpp:2351: DB::InterpreterCreateQuery::execute() @ 0x0000000014905a3a 9. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88dc9 10. /build/src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x0000000014c8ca7b 11. /build/src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000001686da12 12. /build/src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x0000000016870807 13. /build/src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x0000000016907e99 14. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 15. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 16. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 17. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 18. ? @ 0x00007fbc6213eac3 19. ? @ 0x00007fbc621d0850 2025.07.28 11:57:19.037595 [ 17321 ] {30e6e8e1-2e4e-4645-8b58-72d74406d85e} DynamicQueryHandler: Code: 253. DB::Exception: Replica r1 of shard s1 of replicated database at /test/db/test_2 already exists. Replica host ID: '146b4357c08d:9000:19e16180-af7f-43fc-bc12-c25b4ab53332', current host ID: '146b4357c08d:9000:96de0d89-92c2-445b-919b-65d42a702b49'. (REPLICA_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.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&) @ 0x0000000013db5399 4. /build/src/Databases/DatabaseReplicated.cpp:494: DB::DatabaseReplicated::tryConnectToZooKeeperAndInitDatabase(DB::LoadingStrictnessLevel) @ 0x0000000013d91155 5. /build/src/Databases/DatabaseReplicated.cpp:735: DB::DatabaseReplicated::beforeLoadingMetadata(std::shared_ptr, DB::LoadingStrictnessLevel) @ 0x0000000013d954d4 6. /build/src/Databases/TablesLoader.cpp:57: DB::TablesLoader::loadTablesAsync(std::unordered_set, std::hash>, std::equal_to>, std::allocator>>) @ 0x000000001490e734 7. /build/src/Interpreters/InterpreterCreateQuery.cpp:383: DB::InterpreterCreateQuery::createDatabase(DB::ASTCreateQuery&) @ 0x00000000148e8e14 8. /build/src/Interpreters/InterpreterCreateQuery.cpp:2351: DB::InterpreterCreateQuery::execute() @ 0x0000000014905a3a 9. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88dc9 10. /build/src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x0000000014c8ca7b 11. /build/src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000001686da12 12. /build/src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x0000000016870807 13. /build/src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x0000000016907e99 14. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 15. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 16. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 17. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 18. ? @ 0x00007fbc6213eac3 19. ? @ 0x00007fbc621d0850 (version 25.3.6.10636.altinitytest (altinity build)) 2025.07.28 11:57:19.224345 [ 3961 ] {} test_13.rmt2 (7f9b740d-015c-470e-8cc6-8ba33be0dc63): auto DB::StorageReplicatedMergeTree::processQueueEntry(ReplicatedMergeTreeQueue::SelectedEntryPtr)::(anonymous class)::operator()(LogEntryPtr &) const: Code: 86. DB::HTTPException: Received error from remote server http://146b4357c08d:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Ftest%2F01165%2Ftest_13%2Frmt%2Freplicas%2F1&part=20250728_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.6.10636.altinitytest (altinity build)) '. (RECEIVED_ERROR_FROM_REMOTE_IO_SERVER), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.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 const&, int&&, String const&, unsigned long&&, String const&) @ 0x000000000feda8d9 4. /build/src/IO/HTTPCommon.cpp:104: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x000000000feda6e2 5. /build/src/IO/HTTPCommon.cpp:93: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x000000000feda537 6. /build/src/IO/ReadWriteBufferFromHTTP.cpp:277: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x000000001184a4c4 7. /build/src/IO/ReadWriteBufferFromHTTP.cpp:285: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x000000001184a615 8. /build/src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x000000001184ae59 9. /build/src/IO/ReadWriteBufferFromHTTP.cpp:472: void std::__function::__policy_invoker::__call_impl[abi:se190107]>(std::__function::__policy_storage const*) @ 0x000000001184cedd 10. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001184858b 11. /build/src/IO/ReadWriteBufferFromHTTP.cpp:465: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x000000001184bf0b 12. /build/src/IO/ReadBuffer.h:60: DB::ReadBuffer::next() @ 0x000000000a148c7b 13. /build/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) @ 0x0000000011849fb2 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]>&)>&, 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&) @ 0x0000000011841980 15. /build/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) @ 0x000000001621208e 16. /build/src/Storages/StorageReplicatedMergeTree.cpp:5228: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl[abi:se190107] const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000015f9a5fe 17. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000015ed8bfd 18. /build/src/Storages/StorageReplicatedMergeTree.cpp:2514: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x0000000015ec9aab 19. /build/src/Storages/StorageReplicatedMergeTree.cpp:2349: DB::StorageReplicatedMergeTree::executeLogEntry(DB::ReplicatedMergeTreeLogEntry&) @ 0x0000000015eba91b 20. /build/src/Storages/StorageReplicatedMergeTree.cpp:3876: bool std::__function::__policy_invoker&)>::__call_impl[abi:se190107])::$_1, bool (std::shared_ptr&)>>(std::__function::__policy_storage const*, std::shared_ptr&) @ 0x0000000015f9837e 21. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000165d6fc3 22. /build/src/Storages/StorageReplicatedMergeTree.cpp:3872: DB::StorageReplicatedMergeTree::processQueueEntry(std::shared_ptr) @ 0x0000000015efc18a 23. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001624c1b2 24. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000162f9c70 25. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x00000000162fa55a 26. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc6653 27. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000000fccc4c3 28. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc3d92 29. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fcca080 30. ? @ 0x00007fbc6213eac3 31. ? @ 0x00007fbc621d0850 (version 25.3.6.10636.altinitytest (altinity build)) 2025.07.28 11:57:19.244336 [ 17321 ] {69ff78c8-6252-4420-b636-1f9dcfb44370} executeQuery: Code: 253. DB::Exception: Replica r1 of shard s1 of replicated database at /test/db/test_2 already exists. Replica host ID: '146b4357c08d:9000:19e16180-af7f-43fc-bc12-c25b4ab53332', current host ID: '146b4357c08d:9000:c353cd25-3185-4d80-a81e-43a30b030884'. (REPLICA_ALREADY_EXISTS) (version 25.3.6.10636.altinitytest (altinity build)) (from [::1]:42268) (comment: 03229_query_condition_cache.sql) (in query: CREATE DATABASE IF NOT EXISTS test_4426lqfc ENGINE=Replicated('/test/db/test_2', 's1', 'r1') ), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.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&) @ 0x0000000013db5399 4. /build/src/Databases/DatabaseReplicated.cpp:494: DB::DatabaseReplicated::tryConnectToZooKeeperAndInitDatabase(DB::LoadingStrictnessLevel) @ 0x0000000013d91155 5. /build/src/Databases/DatabaseReplicated.cpp:735: DB::DatabaseReplicated::beforeLoadingMetadata(std::shared_ptr, DB::LoadingStrictnessLevel) @ 0x0000000013d954d4 6. /build/src/Databases/TablesLoader.cpp:57: DB::TablesLoader::loadTablesAsync(std::unordered_set, std::hash>, std::equal_to>, std::allocator>>) @ 0x000000001490e734 7. /build/src/Interpreters/InterpreterCreateQuery.cpp:383: DB::InterpreterCreateQuery::createDatabase(DB::ASTCreateQuery&) @ 0x00000000148e8e14 8. /build/src/Interpreters/InterpreterCreateQuery.cpp:2351: DB::InterpreterCreateQuery::execute() @ 0x0000000014905a3a 9. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88dc9 10. /build/src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x0000000014c8ca7b 11. /build/src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000001686da12 12. /build/src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x0000000016870807 13. /build/src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x0000000016907e99 14. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 15. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 16. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 17. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 18. ? @ 0x00007fbc6213eac3 19. ? @ 0x00007fbc621d0850 2025.07.28 11:57:19.256885 [ 17321 ] {69ff78c8-6252-4420-b636-1f9dcfb44370} DynamicQueryHandler: Code: 253. DB::Exception: Replica r1 of shard s1 of replicated database at /test/db/test_2 already exists. Replica host ID: '146b4357c08d:9000:19e16180-af7f-43fc-bc12-c25b4ab53332', current host ID: '146b4357c08d:9000:c353cd25-3185-4d80-a81e-43a30b030884'. (REPLICA_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.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&) @ 0x0000000013db5399 4. /build/src/Databases/DatabaseReplicated.cpp:494: DB::DatabaseReplicated::tryConnectToZooKeeperAndInitDatabase(DB::LoadingStrictnessLevel) @ 0x0000000013d91155 5. /build/src/Databases/DatabaseReplicated.cpp:735: DB::DatabaseReplicated::beforeLoadingMetadata(std::shared_ptr, DB::LoadingStrictnessLevel) @ 0x0000000013d954d4 6. /build/src/Databases/TablesLoader.cpp:57: DB::TablesLoader::loadTablesAsync(std::unordered_set, std::hash>, std::equal_to>, std::allocator>>) @ 0x000000001490e734 7. /build/src/Interpreters/InterpreterCreateQuery.cpp:383: DB::InterpreterCreateQuery::createDatabase(DB::ASTCreateQuery&) @ 0x00000000148e8e14 8. /build/src/Interpreters/InterpreterCreateQuery.cpp:2351: DB::InterpreterCreateQuery::execute() @ 0x0000000014905a3a 9. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88dc9 10. /build/src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x0000000014c8ca7b 11. /build/src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000001686da12 12. /build/src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x0000000016870807 13. /build/src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x0000000016907e99 14. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 15. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 16. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 17. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 18. ? @ 0x00007fbc6213eac3 19. ? @ 0x00007fbc621d0850 (version 25.3.6.10636.altinitytest (altinity build)) 2025.07.28 11:57:19.493165 [ 17232 ] {19aac786-944c-432a-b81f-07dba06b182b} executeQuery: Code: 253. DB::Exception: Replica r1 of shard s1 of replicated database at /test/db/test_2 already exists. Replica host ID: '146b4357c08d:9000:19e16180-af7f-43fc-bc12-c25b4ab53332', current host ID: '146b4357c08d:9000:33a9f509-7bad-4c39-a1ad-b484f0b7e221'. (REPLICA_ALREADY_EXISTS) (version 25.3.6.10636.altinitytest (altinity build)) (from [::1]:42278) (comment: 00022_merge_prewhere.sql) (in query: CREATE DATABASE IF NOT EXISTS test_oopvzjz6 ENGINE=Replicated('/test/db/test_2', 's1', 'r1') ), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.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&) @ 0x0000000013db5399 4. /build/src/Databases/DatabaseReplicated.cpp:494: DB::DatabaseReplicated::tryConnectToZooKeeperAndInitDatabase(DB::LoadingStrictnessLevel) @ 0x0000000013d91155 5. /build/src/Databases/DatabaseReplicated.cpp:735: DB::DatabaseReplicated::beforeLoadingMetadata(std::shared_ptr, DB::LoadingStrictnessLevel) @ 0x0000000013d954d4 6. /build/src/Databases/TablesLoader.cpp:57: DB::TablesLoader::loadTablesAsync(std::unordered_set, std::hash>, std::equal_to>, std::allocator>>) @ 0x000000001490e734 7. /build/src/Interpreters/InterpreterCreateQuery.cpp:383: DB::InterpreterCreateQuery::createDatabase(DB::ASTCreateQuery&) @ 0x00000000148e8e14 8. /build/src/Interpreters/InterpreterCreateQuery.cpp:2351: DB::InterpreterCreateQuery::execute() @ 0x0000000014905a3a 9. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88dc9 10. /build/src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x0000000014c8ca7b 11. /build/src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000001686da12 12. /build/src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x0000000016870807 13. /build/src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x0000000016907e99 14. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 15. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 16. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 17. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 18. ? @ 0x00007fbc6213eac3 19. ? @ 0x00007fbc621d0850 2025.07.28 11:57:19.499417 [ 17232 ] {19aac786-944c-432a-b81f-07dba06b182b} DynamicQueryHandler: Code: 253. DB::Exception: Replica r1 of shard s1 of replicated database at /test/db/test_2 already exists. Replica host ID: '146b4357c08d:9000:19e16180-af7f-43fc-bc12-c25b4ab53332', current host ID: '146b4357c08d:9000:33a9f509-7bad-4c39-a1ad-b484f0b7e221'. (REPLICA_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.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&) @ 0x0000000013db5399 4. /build/src/Databases/DatabaseReplicated.cpp:494: DB::DatabaseReplicated::tryConnectToZooKeeperAndInitDatabase(DB::LoadingStrictnessLevel) @ 0x0000000013d91155 5. /build/src/Databases/DatabaseReplicated.cpp:735: DB::DatabaseReplicated::beforeLoadingMetadata(std::shared_ptr, DB::LoadingStrictnessLevel) @ 0x0000000013d954d4 6. /build/src/Databases/TablesLoader.cpp:57: DB::TablesLoader::loadTablesAsync(std::unordered_set, std::hash>, std::equal_to>, std::allocator>>) @ 0x000000001490e734 7. /build/src/Interpreters/InterpreterCreateQuery.cpp:383: DB::InterpreterCreateQuery::createDatabase(DB::ASTCreateQuery&) @ 0x00000000148e8e14 8. /build/src/Interpreters/InterpreterCreateQuery.cpp:2351: DB::InterpreterCreateQuery::execute() @ 0x0000000014905a3a 9. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88dc9 10. /build/src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x0000000014c8ca7b 11. /build/src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000001686da12 12. /build/src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x0000000016870807 13. /build/src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x0000000016907e99 14. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 15. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 16. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 17. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 18. ? @ 0x00007fbc6213eac3 19. ? @ 0x00007fbc621d0850 (version 25.3.6.10636.altinitytest (altinity build)) 2025.07.28 11:57:19.629802 [ 3287 ] {91299509-f5fd-442a-9641-44a82a0bd67d} executeQuery: Code: 253. DB::Exception: Replica r1 of shard s1 of replicated database at /test/db/test_2 already exists. Replica host ID: '146b4357c08d:9000:19e16180-af7f-43fc-bc12-c25b4ab53332', current host ID: '146b4357c08d:9000:1ccd08bd-8853-4d52-bcd3-9b52dcc7baab'. (REPLICA_ALREADY_EXISTS) (version 25.3.6.10636.altinitytest (altinity build)) (from [::1]:42298) (comment: 01091_num_threads.sql) (in query: CREATE DATABASE IF NOT EXISTS test_5lwvczym ENGINE=Replicated('/test/db/test_2', 's1', 'r1') ), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.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&) @ 0x0000000013db5399 4. /build/src/Databases/DatabaseReplicated.cpp:494: DB::DatabaseReplicated::tryConnectToZooKeeperAndInitDatabase(DB::LoadingStrictnessLevel) @ 0x0000000013d91155 5. /build/src/Databases/DatabaseReplicated.cpp:735: DB::DatabaseReplicated::beforeLoadingMetadata(std::shared_ptr, DB::LoadingStrictnessLevel) @ 0x0000000013d954d4 6. /build/src/Databases/TablesLoader.cpp:57: DB::TablesLoader::loadTablesAsync(std::unordered_set, std::hash>, std::equal_to>, std::allocator>>) @ 0x000000001490e734 7. /build/src/Interpreters/InterpreterCreateQuery.cpp:383: DB::InterpreterCreateQuery::createDatabase(DB::ASTCreateQuery&) @ 0x00000000148e8e14 8. /build/src/Interpreters/InterpreterCreateQuery.cpp:2351: DB::InterpreterCreateQuery::execute() @ 0x0000000014905a3a 9. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88dc9 10. /build/src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x0000000014c8ca7b 11. /build/src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000001686da12 12. /build/src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x0000000016870807 13. /build/src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x0000000016907e99 14. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 15. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 16. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 17. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 18. ? @ 0x00007fbc6213eac3 19. ? @ 0x00007fbc621d0850 2025.07.28 11:57:19.642128 [ 3287 ] {91299509-f5fd-442a-9641-44a82a0bd67d} DynamicQueryHandler: Code: 253. DB::Exception: Replica r1 of shard s1 of replicated database at /test/db/test_2 already exists. Replica host ID: '146b4357c08d:9000:19e16180-af7f-43fc-bc12-c25b4ab53332', current host ID: '146b4357c08d:9000:1ccd08bd-8853-4d52-bcd3-9b52dcc7baab'. (REPLICA_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.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&) @ 0x0000000013db5399 4. /build/src/Databases/DatabaseReplicated.cpp:494: DB::DatabaseReplicated::tryConnectToZooKeeperAndInitDatabase(DB::LoadingStrictnessLevel) @ 0x0000000013d91155 5. /build/src/Databases/DatabaseReplicated.cpp:735: DB::DatabaseReplicated::beforeLoadingMetadata(std::shared_ptr, DB::LoadingStrictnessLevel) @ 0x0000000013d954d4 6. /build/src/Databases/TablesLoader.cpp:57: DB::TablesLoader::loadTablesAsync(std::unordered_set, std::hash>, std::equal_to>, std::allocator>>) @ 0x000000001490e734 7. /build/src/Interpreters/InterpreterCreateQuery.cpp:383: DB::InterpreterCreateQuery::createDatabase(DB::ASTCreateQuery&) @ 0x00000000148e8e14 8. /build/src/Interpreters/InterpreterCreateQuery.cpp:2351: DB::InterpreterCreateQuery::execute() @ 0x0000000014905a3a 9. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88dc9 10. /build/src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x0000000014c8ca7b 11. /build/src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000001686da12 12. /build/src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x0000000016870807 13. /build/src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x0000000016907e99 14. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 15. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 16. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 17. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 18. ? @ 0x00007fbc6213eac3 19. ? @ 0x00007fbc621d0850 (version 25.3.6.10636.altinitytest (altinity build)) 2025.07.28 11:57:19.884323 [ 3287 ] {3c2d0dd8-cbe6-4548-9d43-93e532de6266} executeQuery: Code: 253. DB::Exception: Replica r1 of shard s1 of replicated database at /test/db/test_2 already exists. Replica host ID: '146b4357c08d:9000:19e16180-af7f-43fc-bc12-c25b4ab53332', current host ID: '146b4357c08d:9000:e00f6ba5-92a4-4bb2-bc71-a4782de8901c'. (REPLICA_ALREADY_EXISTS) (version 25.3.6.10636.altinitytest (altinity build)) (from [::1]:42314) (comment: 02726_async_insert_flush_queue.sql) (in query: CREATE DATABASE IF NOT EXISTS test_1iibwp2c ENGINE=Replicated('/test/db/test_2', 's1', 'r1') ), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.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&) @ 0x0000000013db5399 4. /build/src/Databases/DatabaseReplicated.cpp:494: DB::DatabaseReplicated::tryConnectToZooKeeperAndInitDatabase(DB::LoadingStrictnessLevel) @ 0x0000000013d91155 5. /build/src/Databases/DatabaseReplicated.cpp:735: DB::DatabaseReplicated::beforeLoadingMetadata(std::shared_ptr, DB::LoadingStrictnessLevel) @ 0x0000000013d954d4 6. /build/src/Databases/TablesLoader.cpp:57: DB::TablesLoader::loadTablesAsync(std::unordered_set, std::hash>, std::equal_to>, std::allocator>>) @ 0x000000001490e734 7. /build/src/Interpreters/InterpreterCreateQuery.cpp:383: DB::InterpreterCreateQuery::createDatabase(DB::ASTCreateQuery&) @ 0x00000000148e8e14 8. /build/src/Interpreters/InterpreterCreateQuery.cpp:2351: DB::InterpreterCreateQuery::execute() @ 0x0000000014905a3a 9. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88dc9 10. /build/src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x0000000014c8ca7b 11. /build/src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000001686da12 12. /build/src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x0000000016870807 13. /build/src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x0000000016907e99 14. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 15. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 16. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 17. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 18. ? @ 0x00007fbc6213eac3 19. ? @ 0x00007fbc621d0850 2025.07.28 11:57:19.885931 [ 3287 ] {3c2d0dd8-cbe6-4548-9d43-93e532de6266} DynamicQueryHandler: Code: 253. DB::Exception: Replica r1 of shard s1 of replicated database at /test/db/test_2 already exists. Replica host ID: '146b4357c08d:9000:19e16180-af7f-43fc-bc12-c25b4ab53332', current host ID: '146b4357c08d:9000:e00f6ba5-92a4-4bb2-bc71-a4782de8901c'. (REPLICA_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.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&) @ 0x0000000013db5399 4. /build/src/Databases/DatabaseReplicated.cpp:494: DB::DatabaseReplicated::tryConnectToZooKeeperAndInitDatabase(DB::LoadingStrictnessLevel) @ 0x0000000013d91155 5. /build/src/Databases/DatabaseReplicated.cpp:735: DB::DatabaseReplicated::beforeLoadingMetadata(std::shared_ptr, DB::LoadingStrictnessLevel) @ 0x0000000013d954d4 6. /build/src/Databases/TablesLoader.cpp:57: DB::TablesLoader::loadTablesAsync(std::unordered_set, std::hash>, std::equal_to>, std::allocator>>) @ 0x000000001490e734 7. /build/src/Interpreters/InterpreterCreateQuery.cpp:383: DB::InterpreterCreateQuery::createDatabase(DB::ASTCreateQuery&) @ 0x00000000148e8e14 8. /build/src/Interpreters/InterpreterCreateQuery.cpp:2351: DB::InterpreterCreateQuery::execute() @ 0x0000000014905a3a 9. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88dc9 10. /build/src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x0000000014c8ca7b 11. /build/src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000001686da12 12. /build/src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x0000000016870807 13. /build/src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x0000000016907e99 14. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 15. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 16. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 17. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 18. ? @ 0x00007fbc6213eac3 19. ? @ 0x00007fbc621d0850 (version 25.3.6.10636.altinitytest (altinity build)) 2025.07.28 11:57:20.005452 [ 7625 ] {8c70517d-0b18-4450-9c14-38f6bc23aac5} executeQuery: Code: 253. DB::Exception: Replica r1 of shard s1 of replicated database at /test/db/test_2 already exists. Replica host ID: '146b4357c08d:9000:19e16180-af7f-43fc-bc12-c25b4ab53332', current host ID: '146b4357c08d:9000:fef32c10-b92c-42bd-804a-5b47b8c47d0f'. (REPLICA_ALREADY_EXISTS) (version 25.3.6.10636.altinitytest (altinity build)) (from [::1]:42324) (comment: 03231_restore_user_with_existing_role.sh) (in query: CREATE DATABASE IF NOT EXISTS test_10coew84 ENGINE=Replicated('/test/db/test_2', 's1', 'r1') ), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.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&) @ 0x0000000013db5399 4. /build/src/Databases/DatabaseReplicated.cpp:494: DB::DatabaseReplicated::tryConnectToZooKeeperAndInitDatabase(DB::LoadingStrictnessLevel) @ 0x0000000013d91155 5. /build/src/Databases/DatabaseReplicated.cpp:735: DB::DatabaseReplicated::beforeLoadingMetadata(std::shared_ptr, DB::LoadingStrictnessLevel) @ 0x0000000013d954d4 6. /build/src/Databases/TablesLoader.cpp:57: DB::TablesLoader::loadTablesAsync(std::unordered_set, std::hash>, std::equal_to>, std::allocator>>) @ 0x000000001490e734 7. /build/src/Interpreters/InterpreterCreateQuery.cpp:383: DB::InterpreterCreateQuery::createDatabase(DB::ASTCreateQuery&) @ 0x00000000148e8e14 8. /build/src/Interpreters/InterpreterCreateQuery.cpp:2351: DB::InterpreterCreateQuery::execute() @ 0x0000000014905a3a 9. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88dc9 10. /build/src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x0000000014c8ca7b 11. /build/src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000001686da12 12. /build/src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x0000000016870807 13. /build/src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x0000000016907e99 14. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 15. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 16. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 17. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 18. ? @ 0x00007fbc6213eac3 19. ? @ 0x00007fbc621d0850 2025.07.28 11:57:20.007467 [ 7625 ] {8c70517d-0b18-4450-9c14-38f6bc23aac5} DynamicQueryHandler: Code: 253. DB::Exception: Replica r1 of shard s1 of replicated database at /test/db/test_2 already exists. Replica host ID: '146b4357c08d:9000:19e16180-af7f-43fc-bc12-c25b4ab53332', current host ID: '146b4357c08d:9000:fef32c10-b92c-42bd-804a-5b47b8c47d0f'. (REPLICA_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.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&) @ 0x0000000013db5399 4. /build/src/Databases/DatabaseReplicated.cpp:494: DB::DatabaseReplicated::tryConnectToZooKeeperAndInitDatabase(DB::LoadingStrictnessLevel) @ 0x0000000013d91155 5. /build/src/Databases/DatabaseReplicated.cpp:735: DB::DatabaseReplicated::beforeLoadingMetadata(std::shared_ptr, DB::LoadingStrictnessLevel) @ 0x0000000013d954d4 6. /build/src/Databases/TablesLoader.cpp:57: DB::TablesLoader::loadTablesAsync(std::unordered_set, std::hash>, std::equal_to>, std::allocator>>) @ 0x000000001490e734 7. /build/src/Interpreters/InterpreterCreateQuery.cpp:383: DB::InterpreterCreateQuery::createDatabase(DB::ASTCreateQuery&) @ 0x00000000148e8e14 8. /build/src/Interpreters/InterpreterCreateQuery.cpp:2351: DB::InterpreterCreateQuery::execute() @ 0x0000000014905a3a 9. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88dc9 10. /build/src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x0000000014c8ca7b 11. /build/src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000001686da12 12. /build/src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x0000000016870807 13. /build/src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x0000000016907e99 14. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 15. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 16. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 17. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 18. ? @ 0x00007fbc6213eac3 19. ? @ 0x00007fbc621d0850 (version 25.3.6.10636.altinitytest (altinity build)) 2025.07.28 11:57:20.022897 [ 3968 ] {} test_13.rmt2 (7f9b740d-015c-470e-8cc6-8ba33be0dc63): auto DB::StorageReplicatedMergeTree::processQueueEntry(ReplicatedMergeTreeQueue::SelectedEntryPtr)::(anonymous class)::operator()(LogEntryPtr &) const: Code: 86. DB::HTTPException: Received error from remote server http://146b4357c08d:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Ftest%2F01165%2Ftest_13%2Frmt%2Freplicas%2F1&part=20250728_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.6.10636.altinitytest (altinity build)) '. (RECEIVED_ERROR_FROM_REMOTE_IO_SERVER), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.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 const&, int&&, String const&, unsigned long&&, String const&) @ 0x000000000feda8d9 4. /build/src/IO/HTTPCommon.cpp:104: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x000000000feda6e2 5. /build/src/IO/HTTPCommon.cpp:93: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x000000000feda537 6. /build/src/IO/ReadWriteBufferFromHTTP.cpp:277: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x000000001184a4c4 7. /build/src/IO/ReadWriteBufferFromHTTP.cpp:285: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x000000001184a615 8. /build/src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x000000001184ae59 9. /build/src/IO/ReadWriteBufferFromHTTP.cpp:472: void std::__function::__policy_invoker::__call_impl[abi:se190107]>(std::__function::__policy_storage const*) @ 0x000000001184cedd 10. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001184858b 11. /build/src/IO/ReadWriteBufferFromHTTP.cpp:465: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x000000001184bf0b 12. /build/src/IO/ReadBuffer.h:60: DB::ReadBuffer::next() @ 0x000000000a148c7b 13. /build/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) @ 0x0000000011849fb2 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]>&)>&, 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&) @ 0x0000000011841980 15. /build/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) @ 0x000000001621208e 16. /build/src/Storages/StorageReplicatedMergeTree.cpp:5228: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl[abi:se190107] const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000015f9a5fe 17. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000015ed8bfd 18. /build/src/Storages/StorageReplicatedMergeTree.cpp:2514: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x0000000015ec9aab 19. /build/src/Storages/StorageReplicatedMergeTree.cpp:2349: DB::StorageReplicatedMergeTree::executeLogEntry(DB::ReplicatedMergeTreeLogEntry&) @ 0x0000000015eba91b 20. /build/src/Storages/StorageReplicatedMergeTree.cpp:3876: bool std::__function::__policy_invoker&)>::__call_impl[abi:se190107])::$_1, bool (std::shared_ptr&)>>(std::__function::__policy_storage const*, std::shared_ptr&) @ 0x0000000015f9837e 21. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000165d6fc3 22. /build/src/Storages/StorageReplicatedMergeTree.cpp:3872: DB::StorageReplicatedMergeTree::processQueueEntry(std::shared_ptr) @ 0x0000000015efc18a 23. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001624c1b2 24. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000162f9c70 25. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x00000000162fa55a 26. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc6653 27. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000000fccc4c3 28. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc3d92 29. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fcca080 30. ? @ 0x00007fbc6213eac3 31. ? @ 0x00007fbc621d0850 (version 25.3.6.10636.altinitytest (altinity build)) 2025.07.28 11:57:20.051725 [ 4446 ] {9942d869-d616-450f-b62f-0e5cddea836d} executeQuery: Code: 253. DB::Exception: Replica r1 of shard s1 of replicated database at /test/db/test_2 already exists. Replica host ID: '146b4357c08d:9000:19e16180-af7f-43fc-bc12-c25b4ab53332', current host ID: '146b4357c08d:9000:aac4a78d-3d97-4aed-aa14-786f3ed2a54b'. (REPLICA_ALREADY_EXISTS) (version 25.3.6.10636.altinitytest (altinity build)) (from [::1]:42334) (comment: 03033_index_definition_sql_udf_bug.sql) (in query: CREATE DATABASE IF NOT EXISTS test_8s588sxf ENGINE=Replicated('/test/db/test_2', 's1', 'r1') ), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.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&) @ 0x0000000013db5399 4. /build/src/Databases/DatabaseReplicated.cpp:494: DB::DatabaseReplicated::tryConnectToZooKeeperAndInitDatabase(DB::LoadingStrictnessLevel) @ 0x0000000013d91155 5. /build/src/Databases/DatabaseReplicated.cpp:735: DB::DatabaseReplicated::beforeLoadingMetadata(std::shared_ptr, DB::LoadingStrictnessLevel) @ 0x0000000013d954d4 6. /build/src/Databases/TablesLoader.cpp:57: DB::TablesLoader::loadTablesAsync(std::unordered_set, std::hash>, std::equal_to>, std::allocator>>) @ 0x000000001490e734 7. /build/src/Interpreters/InterpreterCreateQuery.cpp:383: DB::InterpreterCreateQuery::createDatabase(DB::ASTCreateQuery&) @ 0x00000000148e8e14 8. /build/src/Interpreters/InterpreterCreateQuery.cpp:2351: DB::InterpreterCreateQuery::execute() @ 0x0000000014905a3a 9. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88dc9 10. /build/src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x0000000014c8ca7b 11. /build/src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000001686da12 12. /build/src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x0000000016870807 13. /build/src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x0000000016907e99 14. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 15. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 16. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 17. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 18. ? @ 0x00007fbc6213eac3 19. ? @ 0x00007fbc621d0850 2025.07.28 11:57:20.053232 [ 4446 ] {9942d869-d616-450f-b62f-0e5cddea836d} DynamicQueryHandler: Code: 253. DB::Exception: Replica r1 of shard s1 of replicated database at /test/db/test_2 already exists. Replica host ID: '146b4357c08d:9000:19e16180-af7f-43fc-bc12-c25b4ab53332', current host ID: '146b4357c08d:9000:aac4a78d-3d97-4aed-aa14-786f3ed2a54b'. (REPLICA_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.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&) @ 0x0000000013db5399 4. /build/src/Databases/DatabaseReplicated.cpp:494: DB::DatabaseReplicated::tryConnectToZooKeeperAndInitDatabase(DB::LoadingStrictnessLevel) @ 0x0000000013d91155 5. /build/src/Databases/DatabaseReplicated.cpp:735: DB::DatabaseReplicated::beforeLoadingMetadata(std::shared_ptr, DB::LoadingStrictnessLevel) @ 0x0000000013d954d4 6. /build/src/Databases/TablesLoader.cpp:57: DB::TablesLoader::loadTablesAsync(std::unordered_set, std::hash>, std::equal_to>, std::allocator>>) @ 0x000000001490e734 7. /build/src/Interpreters/InterpreterCreateQuery.cpp:383: DB::InterpreterCreateQuery::createDatabase(DB::ASTCreateQuery&) @ 0x00000000148e8e14 8. /build/src/Interpreters/InterpreterCreateQuery.cpp:2351: DB::InterpreterCreateQuery::execute() @ 0x0000000014905a3a 9. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88dc9 10. /build/src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x0000000014c8ca7b 11. /build/src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000001686da12 12. /build/src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x0000000016870807 13. /build/src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x0000000016907e99 14. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 15. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 16. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 17. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 18. ? @ 0x00007fbc6213eac3 19. ? @ 0x00007fbc621d0850 (version 25.3.6.10636.altinitytest (altinity build)) 2025.07.28 11:57:20.113504 [ 7625 ] {d58d305a-373b-472c-ac27-b42fcdc7e206} executeQuery: Code: 253. DB::Exception: Replica r1 of shard s1 of replicated database at /test/db/test_2 already exists. Replica host ID: '146b4357c08d:9000:19e16180-af7f-43fc-bc12-c25b4ab53332', current host ID: '146b4357c08d:9000:59d427b7-597e-4ae7-854c-6684b99b88cb'. (REPLICA_ALREADY_EXISTS) (version 25.3.6.10636.altinitytest (altinity build)) (from [::1]:42348) (comment: 02494_query_cache_udf_sql.sql) (in query: CREATE DATABASE IF NOT EXISTS test_pdms4crq ENGINE=Replicated('/test/db/test_2', 's1', 'r1') ), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.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&) @ 0x0000000013db5399 4. /build/src/Databases/DatabaseReplicated.cpp:494: DB::DatabaseReplicated::tryConnectToZooKeeperAndInitDatabase(DB::LoadingStrictnessLevel) @ 0x0000000013d91155 5. /build/src/Databases/DatabaseReplicated.cpp:735: DB::DatabaseReplicated::beforeLoadingMetadata(std::shared_ptr, DB::LoadingStrictnessLevel) @ 0x0000000013d954d4 6. /build/src/Databases/TablesLoader.cpp:57: DB::TablesLoader::loadTablesAsync(std::unordered_set, std::hash>, std::equal_to>, std::allocator>>) @ 0x000000001490e734 7. /build/src/Interpreters/InterpreterCreateQuery.cpp:383: DB::InterpreterCreateQuery::createDatabase(DB::ASTCreateQuery&) @ 0x00000000148e8e14 8. /build/src/Interpreters/InterpreterCreateQuery.cpp:2351: DB::InterpreterCreateQuery::execute() @ 0x0000000014905a3a 9. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88dc9 10. /build/src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x0000000014c8ca7b 11. /build/src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000001686da12 12. /build/src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x0000000016870807 13. /build/src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x0000000016907e99 14. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 15. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 16. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 17. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 18. ? @ 0x00007fbc6213eac3 19. ? @ 0x00007fbc621d0850 2025.07.28 11:57:20.117773 [ 7625 ] {d58d305a-373b-472c-ac27-b42fcdc7e206} DynamicQueryHandler: Code: 253. DB::Exception: Replica r1 of shard s1 of replicated database at /test/db/test_2 already exists. Replica host ID: '146b4357c08d:9000:19e16180-af7f-43fc-bc12-c25b4ab53332', current host ID: '146b4357c08d:9000:59d427b7-597e-4ae7-854c-6684b99b88cb'. (REPLICA_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.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&) @ 0x0000000013db5399 4. /build/src/Databases/DatabaseReplicated.cpp:494: DB::DatabaseReplicated::tryConnectToZooKeeperAndInitDatabase(DB::LoadingStrictnessLevel) @ 0x0000000013d91155 5. /build/src/Databases/DatabaseReplicated.cpp:735: DB::DatabaseReplicated::beforeLoadingMetadata(std::shared_ptr, DB::LoadingStrictnessLevel) @ 0x0000000013d954d4 6. /build/src/Databases/TablesLoader.cpp:57: DB::TablesLoader::loadTablesAsync(std::unordered_set, std::hash>, std::equal_to>, std::allocator>>) @ 0x000000001490e734 7. /build/src/Interpreters/InterpreterCreateQuery.cpp:383: DB::InterpreterCreateQuery::createDatabase(DB::ASTCreateQuery&) @ 0x00000000148e8e14 8. /build/src/Interpreters/InterpreterCreateQuery.cpp:2351: DB::InterpreterCreateQuery::execute() @ 0x0000000014905a3a 9. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88dc9 10. /build/src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x0000000014c8ca7b 11. /build/src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000001686da12 12. /build/src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x0000000016870807 13. /build/src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x0000000016907e99 14. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 15. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 16. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 17. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 18. ? @ 0x00007fbc6213eac3 19. ? @ 0x00007fbc621d0850 (version 25.3.6.10636.altinitytest (altinity build)) 2025.07.28 11:57:20.220604 [ 4446 ] {42520712-85e4-43d5-90af-b2eebe833cc3} executeQuery: Code: 253. DB::Exception: Replica r1 of shard s1 of replicated database at /test/db/test_2 already exists. Replica host ID: '146b4357c08d:9000:19e16180-af7f-43fc-bc12-c25b4ab53332', current host ID: '146b4357c08d:9000:ea13b5b6-8b75-4576-9e2b-310fa680e24c'. (REPLICA_ALREADY_EXISTS) (version 25.3.6.10636.altinitytest (altinity build)) (from [::1]:42358) (comment: 01079_parallel_alter_add_drop_column_zookeeper.sh) (in query: CREATE DATABASE IF NOT EXISTS test_uwewqrgl ENGINE=Replicated('/test/db/test_2', 's1', 'r1') ), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.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&) @ 0x0000000013db5399 4. /build/src/Databases/DatabaseReplicated.cpp:494: DB::DatabaseReplicated::tryConnectToZooKeeperAndInitDatabase(DB::LoadingStrictnessLevel) @ 0x0000000013d91155 5. /build/src/Databases/DatabaseReplicated.cpp:735: DB::DatabaseReplicated::beforeLoadingMetadata(std::shared_ptr, DB::LoadingStrictnessLevel) @ 0x0000000013d954d4 6. /build/src/Databases/TablesLoader.cpp:57: DB::TablesLoader::loadTablesAsync(std::unordered_set, std::hash>, std::equal_to>, std::allocator>>) @ 0x000000001490e734 7. /build/src/Interpreters/InterpreterCreateQuery.cpp:383: DB::InterpreterCreateQuery::createDatabase(DB::ASTCreateQuery&) @ 0x00000000148e8e14 8. /build/src/Interpreters/InterpreterCreateQuery.cpp:2351: DB::InterpreterCreateQuery::execute() @ 0x0000000014905a3a 9. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88dc9 10. /build/src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x0000000014c8ca7b 11. /build/src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000001686da12 12. /build/src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x0000000016870807 13. /build/src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x0000000016907e99 14. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 15. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 16. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 17. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 18. ? @ 0x00007fbc6213eac3 19. ? @ 0x00007fbc621d0850 2025.07.28 11:57:20.222689 [ 4446 ] {42520712-85e4-43d5-90af-b2eebe833cc3} DynamicQueryHandler: Code: 253. DB::Exception: Replica r1 of shard s1 of replicated database at /test/db/test_2 already exists. Replica host ID: '146b4357c08d:9000:19e16180-af7f-43fc-bc12-c25b4ab53332', current host ID: '146b4357c08d:9000:ea13b5b6-8b75-4576-9e2b-310fa680e24c'. (REPLICA_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.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&) @ 0x0000000013db5399 4. /build/src/Databases/DatabaseReplicated.cpp:494: DB::DatabaseReplicated::tryConnectToZooKeeperAndInitDatabase(DB::LoadingStrictnessLevel) @ 0x0000000013d91155 5. /build/src/Databases/DatabaseReplicated.cpp:735: DB::DatabaseReplicated::beforeLoadingMetadata(std::shared_ptr, DB::LoadingStrictnessLevel) @ 0x0000000013d954d4 6. /build/src/Databases/TablesLoader.cpp:57: DB::TablesLoader::loadTablesAsync(std::unordered_set, std::hash>, std::equal_to>, std::allocator>>) @ 0x000000001490e734 7. /build/src/Interpreters/InterpreterCreateQuery.cpp:383: DB::InterpreterCreateQuery::createDatabase(DB::ASTCreateQuery&) @ 0x00000000148e8e14 8. /build/src/Interpreters/InterpreterCreateQuery.cpp:2351: DB::InterpreterCreateQuery::execute() @ 0x0000000014905a3a 9. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88dc9 10. /build/src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x0000000014c8ca7b 11. /build/src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000001686da12 12. /build/src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x0000000016870807 13. /build/src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x0000000016907e99 14. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 15. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 16. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 17. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 18. ? @ 0x00007fbc6213eac3 19. ? @ 0x00007fbc621d0850 (version 25.3.6.10636.altinitytest (altinity build)) 2025.07.28 11:57:20.265028 [ 3287 ] {538041b7-e70d-4794-9050-8e4e04d9b4d1} executeQuery: Code: 253. DB::Exception: Replica r1 of shard s1 of replicated database at /test/db/test_2 already exists. Replica host ID: '146b4357c08d:9000:19e16180-af7f-43fc-bc12-c25b4ab53332', current host ID: '146b4357c08d:9000:4051cfa8-6b2b-4c3b-8f9f-aa9d0fd89ad9'. (REPLICA_ALREADY_EXISTS) (version 25.3.6.10636.altinitytest (altinity build)) (from [::1]:42374) (comment: 02503_insert_storage_snapshot.sh) (in query: CREATE DATABASE IF NOT EXISTS test_pnwpefc4 ENGINE=Replicated('/test/db/test_2', 's1', 'r1') ), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.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&) @ 0x0000000013db5399 4. /build/src/Databases/DatabaseReplicated.cpp:494: DB::DatabaseReplicated::tryConnectToZooKeeperAndInitDatabase(DB::LoadingStrictnessLevel) @ 0x0000000013d91155 5. /build/src/Databases/DatabaseReplicated.cpp:735: DB::DatabaseReplicated::beforeLoadingMetadata(std::shared_ptr, DB::LoadingStrictnessLevel) @ 0x0000000013d954d4 6. /build/src/Databases/TablesLoader.cpp:57: DB::TablesLoader::loadTablesAsync(std::unordered_set, std::hash>, std::equal_to>, std::allocator>>) @ 0x000000001490e734 7. /build/src/Interpreters/InterpreterCreateQuery.cpp:383: DB::InterpreterCreateQuery::createDatabase(DB::ASTCreateQuery&) @ 0x00000000148e8e14 8. /build/src/Interpreters/InterpreterCreateQuery.cpp:2351: DB::InterpreterCreateQuery::execute() @ 0x0000000014905a3a 9. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88dc9 10. /build/src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x0000000014c8ca7b 11. /build/src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000001686da12 12. /build/src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x0000000016870807 13. /build/src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x0000000016907e99 14. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 15. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 16. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 17. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 18. ? @ 0x00007fbc6213eac3 19. ? @ 0x00007fbc621d0850 2025.07.28 11:57:20.267190 [ 3287 ] {538041b7-e70d-4794-9050-8e4e04d9b4d1} DynamicQueryHandler: Code: 253. DB::Exception: Replica r1 of shard s1 of replicated database at /test/db/test_2 already exists. Replica host ID: '146b4357c08d:9000:19e16180-af7f-43fc-bc12-c25b4ab53332', current host ID: '146b4357c08d:9000:4051cfa8-6b2b-4c3b-8f9f-aa9d0fd89ad9'. (REPLICA_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.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&) @ 0x0000000013db5399 4. /build/src/Databases/DatabaseReplicated.cpp:494: DB::DatabaseReplicated::tryConnectToZooKeeperAndInitDatabase(DB::LoadingStrictnessLevel) @ 0x0000000013d91155 5. /build/src/Databases/DatabaseReplicated.cpp:735: DB::DatabaseReplicated::beforeLoadingMetadata(std::shared_ptr, DB::LoadingStrictnessLevel) @ 0x0000000013d954d4 6. /build/src/Databases/TablesLoader.cpp:57: DB::TablesLoader::loadTablesAsync(std::unordered_set, std::hash>, std::equal_to>, std::allocator>>) @ 0x000000001490e734 7. /build/src/Interpreters/InterpreterCreateQuery.cpp:383: DB::InterpreterCreateQuery::createDatabase(DB::ASTCreateQuery&) @ 0x00000000148e8e14 8. /build/src/Interpreters/InterpreterCreateQuery.cpp:2351: DB::InterpreterCreateQuery::execute() @ 0x0000000014905a3a 9. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88dc9 10. /build/src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x0000000014c8ca7b 11. /build/src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000001686da12 12. /build/src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x0000000016870807 13. /build/src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x0000000016907e99 14. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 15. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 16. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 17. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 18. ? @ 0x00007fbc6213eac3 19. ? @ 0x00007fbc621d0850 (version 25.3.6.10636.altinitytest (altinity build)) 2025.07.28 11:57:20.370619 [ 4446 ] {cb901b2b-911b-486e-8414-b8ceaede6b55} executeQuery: Code: 253. DB::Exception: Replica r1 of shard s1 of replicated database at /test/db/test_2 already exists. Replica host ID: '146b4357c08d:9000:19e16180-af7f-43fc-bc12-c25b4ab53332', current host ID: '146b4357c08d:9000:ca4763e5-e855-4405-888c-1eb2c2478ccf'. (REPLICA_ALREADY_EXISTS) (version 25.3.6.10636.altinitytest (altinity build)) (from [::1]:42386) (comment: 02314_avro_null_as_default.sh) (in query: CREATE DATABASE IF NOT EXISTS test_m1ehzkk3 ENGINE=Replicated('/test/db/test_2', 's1', 'r1') ), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.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&) @ 0x0000000013db5399 4. /build/src/Databases/DatabaseReplicated.cpp:494: DB::DatabaseReplicated::tryConnectToZooKeeperAndInitDatabase(DB::LoadingStrictnessLevel) @ 0x0000000013d91155 5. /build/src/Databases/DatabaseReplicated.cpp:735: DB::DatabaseReplicated::beforeLoadingMetadata(std::shared_ptr, DB::LoadingStrictnessLevel) @ 0x0000000013d954d4 6. /build/src/Databases/TablesLoader.cpp:57: DB::TablesLoader::loadTablesAsync(std::unordered_set, std::hash>, std::equal_to>, std::allocator>>) @ 0x000000001490e734 7. /build/src/Interpreters/InterpreterCreateQuery.cpp:383: DB::InterpreterCreateQuery::createDatabase(DB::ASTCreateQuery&) @ 0x00000000148e8e14 8. /build/src/Interpreters/InterpreterCreateQuery.cpp:2351: DB::InterpreterCreateQuery::execute() @ 0x0000000014905a3a 9. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88dc9 10. /build/src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x0000000014c8ca7b 11. /build/src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000001686da12 12. /build/src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x0000000016870807 13. /build/src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x0000000016907e99 14. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 15. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 16. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 17. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 18. ? @ 0x00007fbc6213eac3 19. ? @ 0x00007fbc621d0850 2025.07.28 11:57:20.373031 [ 4446 ] {cb901b2b-911b-486e-8414-b8ceaede6b55} DynamicQueryHandler: Code: 253. DB::Exception: Replica r1 of shard s1 of replicated database at /test/db/test_2 already exists. Replica host ID: '146b4357c08d:9000:19e16180-af7f-43fc-bc12-c25b4ab53332', current host ID: '146b4357c08d:9000:ca4763e5-e855-4405-888c-1eb2c2478ccf'. (REPLICA_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.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&) @ 0x0000000013db5399 4. /build/src/Databases/DatabaseReplicated.cpp:494: DB::DatabaseReplicated::tryConnectToZooKeeperAndInitDatabase(DB::LoadingStrictnessLevel) @ 0x0000000013d91155 5. /build/src/Databases/DatabaseReplicated.cpp:735: DB::DatabaseReplicated::beforeLoadingMetadata(std::shared_ptr, DB::LoadingStrictnessLevel) @ 0x0000000013d954d4 6. /build/src/Databases/TablesLoader.cpp:57: DB::TablesLoader::loadTablesAsync(std::unordered_set, std::hash>, std::equal_to>, std::allocator>>) @ 0x000000001490e734 7. /build/src/Interpreters/InterpreterCreateQuery.cpp:383: DB::InterpreterCreateQuery::createDatabase(DB::ASTCreateQuery&) @ 0x00000000148e8e14 8. /build/src/Interpreters/InterpreterCreateQuery.cpp:2351: DB::InterpreterCreateQuery::execute() @ 0x0000000014905a3a 9. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88dc9 10. /build/src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x0000000014c8ca7b 11. /build/src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000001686da12 12. /build/src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x0000000016870807 13. /build/src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x0000000016907e99 14. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 15. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 16. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 17. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 18. ? @ 0x00007fbc6213eac3 19. ? @ 0x00007fbc621d0850 (version 25.3.6.10636.altinitytest (altinity build)) 2025.07.28 11:57:20.443621 [ 3287 ] {cafd36a4-200b-4385-983f-962a293cbf74} executeQuery: Code: 253. DB::Exception: Replica r1 of shard s1 of replicated database at /test/db/test_2 already exists. Replica host ID: '146b4357c08d:9000:19e16180-af7f-43fc-bc12-c25b4ab53332', current host ID: '146b4357c08d:9000:711d70c7-e5e4-4702-a735-0b75b1c3fc92'. (REPLICA_ALREADY_EXISTS) (version 25.3.6.10636.altinitytest (altinity build)) (from [::1]:42394) (comment: 01946_test_zstd_decompression_with_escape_sequence_at_the_end_of_buffer.sh) (in query: CREATE DATABASE IF NOT EXISTS test_3j7737bn ENGINE=Replicated('/test/db/test_2', 's1', 'r1') ), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.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&) @ 0x0000000013db5399 4. /build/src/Databases/DatabaseReplicated.cpp:494: DB::DatabaseReplicated::tryConnectToZooKeeperAndInitDatabase(DB::LoadingStrictnessLevel) @ 0x0000000013d91155 5. /build/src/Databases/DatabaseReplicated.cpp:735: DB::DatabaseReplicated::beforeLoadingMetadata(std::shared_ptr, DB::LoadingStrictnessLevel) @ 0x0000000013d954d4 6. /build/src/Databases/TablesLoader.cpp:57: DB::TablesLoader::loadTablesAsync(std::unordered_set, std::hash>, std::equal_to>, std::allocator>>) @ 0x000000001490e734 7. /build/src/Interpreters/InterpreterCreateQuery.cpp:383: DB::InterpreterCreateQuery::createDatabase(DB::ASTCreateQuery&) @ 0x00000000148e8e14 8. /build/src/Interpreters/InterpreterCreateQuery.cpp:2351: DB::InterpreterCreateQuery::execute() @ 0x0000000014905a3a 9. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88dc9 10. /build/src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x0000000014c8ca7b 11. /build/src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000001686da12 12. /build/src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x0000000016870807 13. /build/src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x0000000016907e99 14. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 15. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 16. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 17. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 18. ? @ 0x00007fbc6213eac3 19. ? @ 0x00007fbc621d0850 2025.07.28 11:57:20.446070 [ 3287 ] {cafd36a4-200b-4385-983f-962a293cbf74} DynamicQueryHandler: Code: 253. DB::Exception: Replica r1 of shard s1 of replicated database at /test/db/test_2 already exists. Replica host ID: '146b4357c08d:9000:19e16180-af7f-43fc-bc12-c25b4ab53332', current host ID: '146b4357c08d:9000:711d70c7-e5e4-4702-a735-0b75b1c3fc92'. (REPLICA_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.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&) @ 0x0000000013db5399 4. /build/src/Databases/DatabaseReplicated.cpp:494: DB::DatabaseReplicated::tryConnectToZooKeeperAndInitDatabase(DB::LoadingStrictnessLevel) @ 0x0000000013d91155 5. /build/src/Databases/DatabaseReplicated.cpp:735: DB::DatabaseReplicated::beforeLoadingMetadata(std::shared_ptr, DB::LoadingStrictnessLevel) @ 0x0000000013d954d4 6. /build/src/Databases/TablesLoader.cpp:57: DB::TablesLoader::loadTablesAsync(std::unordered_set, std::hash>, std::equal_to>, std::allocator>>) @ 0x000000001490e734 7. /build/src/Interpreters/InterpreterCreateQuery.cpp:383: DB::InterpreterCreateQuery::createDatabase(DB::ASTCreateQuery&) @ 0x00000000148e8e14 8. /build/src/Interpreters/InterpreterCreateQuery.cpp:2351: DB::InterpreterCreateQuery::execute() @ 0x0000000014905a3a 9. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88dc9 10. /build/src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x0000000014c8ca7b 11. /build/src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000001686da12 12. /build/src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x0000000016870807 13. /build/src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x0000000016907e99 14. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 15. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 16. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 17. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 18. ? @ 0x00007fbc6213eac3 19. ? @ 0x00007fbc621d0850 (version 25.3.6.10636.altinitytest (altinity build)) 2025.07.28 11:57:20.557327 [ 17232 ] {d8a274c2-e51c-4d59-9e08-c861c0b5ddd4} executeQuery: Code: 253. DB::Exception: Replica r1 of shard s1 of replicated database at /test/db/test_2 already exists. Replica host ID: '146b4357c08d:9000:19e16180-af7f-43fc-bc12-c25b4ab53332', current host ID: '146b4357c08d:9000:8b2a4244-e3d6-4ac8-93b7-240bc7df6b7d'. (REPLICA_ALREADY_EXISTS) (version 25.3.6.10636.altinitytest (altinity build)) (from [::1]:42414) (comment: 00176_distinct_limit_by_limit_bug_43377.sql) (in query: CREATE DATABASE IF NOT EXISTS test_i9ku61pn ENGINE=Replicated('/test/db/test_2', 's1', 'r1') ), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.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&) @ 0x0000000013db5399 4. /build/src/Databases/DatabaseReplicated.cpp:494: DB::DatabaseReplicated::tryConnectToZooKeeperAndInitDatabase(DB::LoadingStrictnessLevel) @ 0x0000000013d91155 5. /build/src/Databases/DatabaseReplicated.cpp:735: DB::DatabaseReplicated::beforeLoadingMetadata(std::shared_ptr, DB::LoadingStrictnessLevel) @ 0x0000000013d954d4 6. /build/src/Databases/TablesLoader.cpp:57: DB::TablesLoader::loadTablesAsync(std::unordered_set, std::hash>, std::equal_to>, std::allocator>>) @ 0x000000001490e734 7. /build/src/Interpreters/InterpreterCreateQuery.cpp:383: DB::InterpreterCreateQuery::createDatabase(DB::ASTCreateQuery&) @ 0x00000000148e8e14 8. /build/src/Interpreters/InterpreterCreateQuery.cpp:2351: DB::InterpreterCreateQuery::execute() @ 0x0000000014905a3a 9. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88dc9 10. /build/src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x0000000014c8ca7b 11. /build/src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000001686da12 12. /build/src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x0000000016870807 13. /build/src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x0000000016907e99 14. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 15. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 16. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 17. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 18. ? @ 0x00007fbc6213eac3 19. ? @ 0x00007fbc621d0850 2025.07.28 11:57:20.583040 [ 17232 ] {d8a274c2-e51c-4d59-9e08-c861c0b5ddd4} DynamicQueryHandler: Code: 253. DB::Exception: Replica r1 of shard s1 of replicated database at /test/db/test_2 already exists. Replica host ID: '146b4357c08d:9000:19e16180-af7f-43fc-bc12-c25b4ab53332', current host ID: '146b4357c08d:9000:8b2a4244-e3d6-4ac8-93b7-240bc7df6b7d'. (REPLICA_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.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&) @ 0x0000000013db5399 4. /build/src/Databases/DatabaseReplicated.cpp:494: DB::DatabaseReplicated::tryConnectToZooKeeperAndInitDatabase(DB::LoadingStrictnessLevel) @ 0x0000000013d91155 5. /build/src/Databases/DatabaseReplicated.cpp:735: DB::DatabaseReplicated::beforeLoadingMetadata(std::shared_ptr, DB::LoadingStrictnessLevel) @ 0x0000000013d954d4 6. /build/src/Databases/TablesLoader.cpp:57: DB::TablesLoader::loadTablesAsync(std::unordered_set, std::hash>, std::equal_to>, std::allocator>>) @ 0x000000001490e734 7. /build/src/Interpreters/InterpreterCreateQuery.cpp:383: DB::InterpreterCreateQuery::createDatabase(DB::ASTCreateQuery&) @ 0x00000000148e8e14 8. /build/src/Interpreters/InterpreterCreateQuery.cpp:2351: DB::InterpreterCreateQuery::execute() @ 0x0000000014905a3a 9. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88dc9 10. /build/src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x0000000014c8ca7b 11. /build/src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000001686da12 12. /build/src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x0000000016870807 13. /build/src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x0000000016907e99 14. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 15. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 16. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 17. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 18. ? @ 0x00007fbc6213eac3 19. ? @ 0x00007fbc621d0850 (version 25.3.6.10636.altinitytest (altinity build)) 2025.07.28 11:57:20.630014 [ 5825 ] {550faa44-1fa9-4dd9-892c-27aab0e4dc33} executeQuery: Code: 253. DB::Exception: Replica r1 of shard s1 of replicated database at /test/db/test_2 already exists. Replica host ID: '146b4357c08d:9000:19e16180-af7f-43fc-bc12-c25b4ab53332', current host ID: '146b4357c08d:9000:cf53f3a9-f737-46ef-a10e-5539423d6e3c'. (REPLICA_ALREADY_EXISTS) (version 25.3.6.10636.altinitytest (altinity build)) (from [::1]:42428) (comment: 01070_modify_ttl_recalc_only.sql) (in query: CREATE DATABASE IF NOT EXISTS test_y2xhiypw ENGINE=Replicated('/test/db/test_2', 's1', 'r1') ), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.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&) @ 0x0000000013db5399 4. /build/src/Databases/DatabaseReplicated.cpp:494: DB::DatabaseReplicated::tryConnectToZooKeeperAndInitDatabase(DB::LoadingStrictnessLevel) @ 0x0000000013d91155 5. /build/src/Databases/DatabaseReplicated.cpp:735: DB::DatabaseReplicated::beforeLoadingMetadata(std::shared_ptr, DB::LoadingStrictnessLevel) @ 0x0000000013d954d4 6. /build/src/Databases/TablesLoader.cpp:57: DB::TablesLoader::loadTablesAsync(std::unordered_set, std::hash>, std::equal_to>, std::allocator>>) @ 0x000000001490e734 7. /build/src/Interpreters/InterpreterCreateQuery.cpp:383: DB::InterpreterCreateQuery::createDatabase(DB::ASTCreateQuery&) @ 0x00000000148e8e14 8. /build/src/Interpreters/InterpreterCreateQuery.cpp:2351: DB::InterpreterCreateQuery::execute() @ 0x0000000014905a3a 9. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88dc9 10. /build/src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x0000000014c8ca7b 11. /build/src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000001686da12 12. /build/src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x0000000016870807 13. /build/src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x0000000016907e99 14. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 15. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 16. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 17. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 18. ? @ 0x00007fbc6213eac3 19. ? @ 0x00007fbc621d0850 2025.07.28 11:57:20.635568 [ 5825 ] {550faa44-1fa9-4dd9-892c-27aab0e4dc33} DynamicQueryHandler: Code: 253. DB::Exception: Replica r1 of shard s1 of replicated database at /test/db/test_2 already exists. Replica host ID: '146b4357c08d:9000:19e16180-af7f-43fc-bc12-c25b4ab53332', current host ID: '146b4357c08d:9000:cf53f3a9-f737-46ef-a10e-5539423d6e3c'. (REPLICA_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.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&) @ 0x0000000013db5399 4. /build/src/Databases/DatabaseReplicated.cpp:494: DB::DatabaseReplicated::tryConnectToZooKeeperAndInitDatabase(DB::LoadingStrictnessLevel) @ 0x0000000013d91155 5. /build/src/Databases/DatabaseReplicated.cpp:735: DB::DatabaseReplicated::beforeLoadingMetadata(std::shared_ptr, DB::LoadingStrictnessLevel) @ 0x0000000013d954d4 6. /build/src/Databases/TablesLoader.cpp:57: DB::TablesLoader::loadTablesAsync(std::unordered_set, std::hash>, std::equal_to>, std::allocator>>) @ 0x000000001490e734 7. /build/src/Interpreters/InterpreterCreateQuery.cpp:383: DB::InterpreterCreateQuery::createDatabase(DB::ASTCreateQuery&) @ 0x00000000148e8e14 8. /build/src/Interpreters/InterpreterCreateQuery.cpp:2351: DB::InterpreterCreateQuery::execute() @ 0x0000000014905a3a 9. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88dc9 10. /build/src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x0000000014c8ca7b 11. /build/src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000001686da12 12. /build/src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x0000000016870807 13. /build/src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x0000000016907e99 14. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 15. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 16. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 17. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 18. ? @ 0x00007fbc6213eac3 19. ? @ 0x00007fbc621d0850 (version 25.3.6.10636.altinitytest (altinity build)) 2025.07.28 11:57:20.703340 [ 17232 ] {717d3ee3-0757-4004-96b3-d98a95469a78} executeQuery: Code: 253. DB::Exception: Replica r1 of shard s1 of replicated database at /test/db/test_2 already exists. Replica host ID: '146b4357c08d:9000:19e16180-af7f-43fc-bc12-c25b4ab53332', current host ID: '146b4357c08d:9000:abbd944f-98e0-4564-8fb9-33c4b390eab4'. (REPLICA_ALREADY_EXISTS) (version 25.3.6.10636.altinitytest (altinity build)) (from [::1]:42442) (comment: 01939_user_with_default_database.sh) (in query: CREATE DATABASE IF NOT EXISTS test_edtjt02y ENGINE=Replicated('/test/db/test_2', 's1', 'r1') ), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.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&) @ 0x0000000013db5399 4. /build/src/Databases/DatabaseReplicated.cpp:494: DB::DatabaseReplicated::tryConnectToZooKeeperAndInitDatabase(DB::LoadingStrictnessLevel) @ 0x0000000013d91155 5. /build/src/Databases/DatabaseReplicated.cpp:735: DB::DatabaseReplicated::beforeLoadingMetadata(std::shared_ptr, DB::LoadingStrictnessLevel) @ 0x0000000013d954d4 6. /build/src/Databases/TablesLoader.cpp:57: DB::TablesLoader::loadTablesAsync(std::unordered_set, std::hash>, std::equal_to>, std::allocator>>) @ 0x000000001490e734 7. /build/src/Interpreters/InterpreterCreateQuery.cpp:383: DB::InterpreterCreateQuery::createDatabase(DB::ASTCreateQuery&) @ 0x00000000148e8e14 8. /build/src/Interpreters/InterpreterCreateQuery.cpp:2351: DB::InterpreterCreateQuery::execute() @ 0x0000000014905a3a 9. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88dc9 10. /build/src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x0000000014c8ca7b 11. /build/src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000001686da12 12. /build/src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x0000000016870807 13. /build/src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x0000000016907e99 14. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 15. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 16. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 17. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 18. ? @ 0x00007fbc6213eac3 19. ? @ 0x00007fbc621d0850 2025.07.28 11:57:20.721390 [ 17232 ] {717d3ee3-0757-4004-96b3-d98a95469a78} DynamicQueryHandler: Code: 253. DB::Exception: Replica r1 of shard s1 of replicated database at /test/db/test_2 already exists. Replica host ID: '146b4357c08d:9000:19e16180-af7f-43fc-bc12-c25b4ab53332', current host ID: '146b4357c08d:9000:abbd944f-98e0-4564-8fb9-33c4b390eab4'. (REPLICA_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.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&) @ 0x0000000013db5399 4. /build/src/Databases/DatabaseReplicated.cpp:494: DB::DatabaseReplicated::tryConnectToZooKeeperAndInitDatabase(DB::LoadingStrictnessLevel) @ 0x0000000013d91155 5. /build/src/Databases/DatabaseReplicated.cpp:735: DB::DatabaseReplicated::beforeLoadingMetadata(std::shared_ptr, DB::LoadingStrictnessLevel) @ 0x0000000013d954d4 6. /build/src/Databases/TablesLoader.cpp:57: DB::TablesLoader::loadTablesAsync(std::unordered_set, std::hash>, std::equal_to>, std::allocator>>) @ 0x000000001490e734 7. /build/src/Interpreters/InterpreterCreateQuery.cpp:383: DB::InterpreterCreateQuery::createDatabase(DB::ASTCreateQuery&) @ 0x00000000148e8e14 8. /build/src/Interpreters/InterpreterCreateQuery.cpp:2351: DB::InterpreterCreateQuery::execute() @ 0x0000000014905a3a 9. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88dc9 10. /build/src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x0000000014c8ca7b 11. /build/src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000001686da12 12. /build/src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x0000000016870807 13. /build/src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x0000000016907e99 14. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 15. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 16. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 17. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 18. ? @ 0x00007fbc6213eac3 19. ? @ 0x00007fbc621d0850 (version 25.3.6.10636.altinitytest (altinity build)) 2025.07.28 11:57:20.927562 [ 3965 ] {} test_13.rmt2 (7f9b740d-015c-470e-8cc6-8ba33be0dc63): auto DB::StorageReplicatedMergeTree::processQueueEntry(ReplicatedMergeTreeQueue::SelectedEntryPtr)::(anonymous class)::operator()(LogEntryPtr &) const: Code: 86. DB::HTTPException: Received error from remote server http://146b4357c08d:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Ftest%2F01165%2Ftest_13%2Frmt%2Freplicas%2F1&part=20250728_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.6.10636.altinitytest (altinity build)) '. (RECEIVED_ERROR_FROM_REMOTE_IO_SERVER), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.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 const&, int&&, String const&, unsigned long&&, String const&) @ 0x000000000feda8d9 4. /build/src/IO/HTTPCommon.cpp:104: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x000000000feda6e2 5. /build/src/IO/HTTPCommon.cpp:93: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x000000000feda537 6. /build/src/IO/ReadWriteBufferFromHTTP.cpp:277: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x000000001184a4c4 7. /build/src/IO/ReadWriteBufferFromHTTP.cpp:285: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x000000001184a615 8. /build/src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x000000001184ae59 9. /build/src/IO/ReadWriteBufferFromHTTP.cpp:472: void std::__function::__policy_invoker::__call_impl[abi:se190107]>(std::__function::__policy_storage const*) @ 0x000000001184cedd 10. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001184858b 11. /build/src/IO/ReadWriteBufferFromHTTP.cpp:465: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x000000001184bf0b 12. /build/src/IO/ReadBuffer.h:60: DB::ReadBuffer::next() @ 0x000000000a148c7b 13. /build/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) @ 0x0000000011849fb2 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]>&)>&, 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&) @ 0x0000000011841980 15. /build/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) @ 0x000000001621208e 16. /build/src/Storages/StorageReplicatedMergeTree.cpp:5228: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl[abi:se190107] const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000015f9a5fe 17. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000015ed8bfd 18. /build/src/Storages/StorageReplicatedMergeTree.cpp:2514: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x0000000015ec9aab 19. /build/src/Storages/StorageReplicatedMergeTree.cpp:2349: DB::StorageReplicatedMergeTree::executeLogEntry(DB::ReplicatedMergeTreeLogEntry&) @ 0x0000000015eba91b 20. /build/src/Storages/StorageReplicatedMergeTree.cpp:3876: bool std::__function::__policy_invoker&)>::__call_impl[abi:se190107])::$_1, bool (std::shared_ptr&)>>(std::__function::__policy_storage const*, std::shared_ptr&) @ 0x0000000015f9837e 21. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000165d6fc3 22. /build/src/Storages/StorageReplicatedMergeTree.cpp:3872: DB::StorageReplicatedMergeTree::processQueueEntry(std::shared_ptr) @ 0x0000000015efc18a 23. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001624c1b2 24. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000162f9c70 25. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x00000000162fa55a 26. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc6653 27. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000000fccc4c3 28. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc3d92 29. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fcca080 30. ? @ 0x00007fbc6213eac3 31. ? @ 0x00007fbc621d0850 (version 25.3.6.10636.altinitytest (altinity build)) 2025.07.28 11:57:21.942570 [ 17611 ] {} 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. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception>&, String>(int, FormatStringHelperImpl>&>::type, std::type_identity::type>, std::basic_string_view>&, String&&) @ 0x000000001385a5eb 4. /build/src/Access/SettingsConstraints.cpp:376: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000013859b18 5. /build/src/Access/SettingsConstraints.cpp:300: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000013858faf 6. /build/src/Access/SettingsConstraints.cpp:209: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000013859223 7. /build/src/Interpreters/Context.cpp:2690: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000014436134 8. /build/src/Interpreters/Context.cpp:2729: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x000000001443662b 9. /build/src/Server/HTTPHandler.cpp:457: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000001686d165 10. /build/src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x0000000016870807 11. /build/src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x0000000016907e99 12. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 13. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 14. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 15. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 16. ? @ 0x00007fbc6213eac3 17. ? @ 0x00007fbc621d0850 (version 25.3.6.10636.altinitytest (altinity build)) 2025.07.28 11:57:22.003177 [ 3962 ] {} test_13.rmt2 (7f9b740d-015c-470e-8cc6-8ba33be0dc63): auto DB::StorageReplicatedMergeTree::processQueueEntry(ReplicatedMergeTreeQueue::SelectedEntryPtr)::(anonymous class)::operator()(LogEntryPtr &) const: Code: 86. DB::HTTPException: Received error from remote server http://146b4357c08d:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Ftest%2F01165%2Ftest_13%2Frmt%2Freplicas%2F1&part=20250728_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.6.10636.altinitytest (altinity build)) '. (RECEIVED_ERROR_FROM_REMOTE_IO_SERVER), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.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 const&, int&&, String const&, unsigned long&&, String const&) @ 0x000000000feda8d9 4. /build/src/IO/HTTPCommon.cpp:104: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x000000000feda6e2 5. /build/src/IO/HTTPCommon.cpp:93: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x000000000feda537 6. /build/src/IO/ReadWriteBufferFromHTTP.cpp:277: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x000000001184a4c4 7. /build/src/IO/ReadWriteBufferFromHTTP.cpp:285: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x000000001184a615 8. /build/src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x000000001184ae59 9. /build/src/IO/ReadWriteBufferFromHTTP.cpp:472: void std::__function::__policy_invoker::__call_impl[abi:se190107]>(std::__function::__policy_storage const*) @ 0x000000001184cedd 10. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001184858b 11. /build/src/IO/ReadWriteBufferFromHTTP.cpp:465: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x000000001184bf0b 12. /build/src/IO/ReadBuffer.h:60: DB::ReadBuffer::next() @ 0x000000000a148c7b 13. /build/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) @ 0x0000000011849fb2 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]>&)>&, 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&) @ 0x0000000011841980 15. /build/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) @ 0x000000001621208e 16. /build/src/Storages/StorageReplicatedMergeTree.cpp:5228: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl[abi:se190107] const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000015f9a5fe 17. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000015ed8bfd 18. /build/src/Storages/StorageReplicatedMergeTree.cpp:2514: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x0000000015ec9aab 19. /build/src/Storages/StorageReplicatedMergeTree.cpp:2349: DB::StorageReplicatedMergeTree::executeLogEntry(DB::ReplicatedMergeTreeLogEntry&) @ 0x0000000015eba91b 20. /build/src/Storages/StorageReplicatedMergeTree.cpp:3876: bool std::__function::__policy_invoker&)>::__call_impl[abi:se190107])::$_1, bool (std::shared_ptr&)>>(std::__function::__policy_storage const*, std::shared_ptr&) @ 0x0000000015f9837e 21. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000165d6fc3 22. /build/src/Storages/StorageReplicatedMergeTree.cpp:3872: DB::StorageReplicatedMergeTree::processQueueEntry(std::shared_ptr) @ 0x0000000015efc18a 23. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001624c1b2 24. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000162f9c70 25. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x00000000162fa55a 26. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc6653 27. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000000fccc4c3 28. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc3d92 29. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fcca080 30. ? @ 0x00007fbc6213eac3 31. ? @ 0x00007fbc621d0850 (version 25.3.6.10636.altinitytest (altinity build)) 2025.07.28 11:57:22.532206 [ 3970 ] {} test_13.rmt2 (7f9b740d-015c-470e-8cc6-8ba33be0dc63): auto DB::StorageReplicatedMergeTree::processQueueEntry(ReplicatedMergeTreeQueue::SelectedEntryPtr)::(anonymous class)::operator()(LogEntryPtr &) const: Code: 86. DB::HTTPException: Received error from remote server http://146b4357c08d:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Ftest%2F01165%2Ftest_13%2Frmt%2Freplicas%2F1&part=20250728_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.6.10636.altinitytest (altinity build)) '. (RECEIVED_ERROR_FROM_REMOTE_IO_SERVER), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.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 const&, int&&, String const&, unsigned long&&, String const&) @ 0x000000000feda8d9 4. /build/src/IO/HTTPCommon.cpp:104: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x000000000feda6e2 5. /build/src/IO/HTTPCommon.cpp:93: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x000000000feda537 6. /build/src/IO/ReadWriteBufferFromHTTP.cpp:277: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x000000001184a4c4 7. /build/src/IO/ReadWriteBufferFromHTTP.cpp:285: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x000000001184a615 8. /build/src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x000000001184ae59 9. /build/src/IO/ReadWriteBufferFromHTTP.cpp:472: void std::__function::__policy_invoker::__call_impl[abi:se190107]>(std::__function::__policy_storage const*) @ 0x000000001184cedd 10. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001184858b 11. /build/src/IO/ReadWriteBufferFromHTTP.cpp:465: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x000000001184bf0b 12. /build/src/IO/ReadBuffer.h:60: DB::ReadBuffer::next() @ 0x000000000a148c7b 13. /build/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) @ 0x0000000011849fb2 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]>&)>&, 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&) @ 0x0000000011841980 15. /build/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) @ 0x000000001621208e 16. /build/src/Storages/StorageReplicatedMergeTree.cpp:5228: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl[abi:se190107] const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000015f9a5fe 17. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000015ed8bfd 18. /build/src/Storages/StorageReplicatedMergeTree.cpp:2514: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x0000000015ec9aab 19. /build/src/Storages/StorageReplicatedMergeTree.cpp:2349: DB::StorageReplicatedMergeTree::executeLogEntry(DB::ReplicatedMergeTreeLogEntry&) @ 0x0000000015eba91b 20. /build/src/Storages/StorageReplicatedMergeTree.cpp:3876: bool std::__function::__policy_invoker&)>::__call_impl[abi:se190107])::$_1, bool (std::shared_ptr&)>>(std::__function::__policy_storage const*, std::shared_ptr&) @ 0x0000000015f9837e 21. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000165d6fc3 22. /build/src/Storages/StorageReplicatedMergeTree.cpp:3872: DB::StorageReplicatedMergeTree::processQueueEntry(std::shared_ptr) @ 0x0000000015efc18a 23. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001624c1b2 24. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000162f9c70 25. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x00000000162fa55a 26. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc6653 27. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000000fccc4c3 28. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc3d92 29. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fcca080 30. ? @ 0x00007fbc6213eac3 31. ? @ 0x00007fbc621d0850 (version 25.3.6.10636.altinitytest (altinity build)) 2025.07.28 11:57:23.556098 [ 3971 ] {} test_13.rmt2 (7f9b740d-015c-470e-8cc6-8ba33be0dc63): auto DB::StorageReplicatedMergeTree::processQueueEntry(ReplicatedMergeTreeQueue::SelectedEntryPtr)::(anonymous class)::operator()(LogEntryPtr &) const: Code: 86. DB::HTTPException: Received error from remote server http://146b4357c08d:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Ftest%2F01165%2Ftest_13%2Frmt%2Freplicas%2F1&part=20250728_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.6.10636.altinitytest (altinity build)) '. (RECEIVED_ERROR_FROM_REMOTE_IO_SERVER), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.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 const&, int&&, String const&, unsigned long&&, String const&) @ 0x000000000feda8d9 4. /build/src/IO/HTTPCommon.cpp:104: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x000000000feda6e2 5. /build/src/IO/HTTPCommon.cpp:93: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x000000000feda537 6. /build/src/IO/ReadWriteBufferFromHTTP.cpp:277: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x000000001184a4c4 7. /build/src/IO/ReadWriteBufferFromHTTP.cpp:285: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x000000001184a615 8. /build/src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x000000001184ae59 9. /build/src/IO/ReadWriteBufferFromHTTP.cpp:472: void std::__function::__policy_invoker::__call_impl[abi:se190107]>(std::__function::__policy_storage const*) @ 0x000000001184cedd 10. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001184858b 11. /build/src/IO/ReadWriteBufferFromHTTP.cpp:465: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x000000001184bf0b 12. /build/src/IO/ReadBuffer.h:60: DB::ReadBuffer::next() @ 0x000000000a148c7b 13. /build/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) @ 0x0000000011849fb2 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]>&)>&, 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&) @ 0x0000000011841980 15. /build/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) @ 0x000000001621208e 16. /build/src/Storages/StorageReplicatedMergeTree.cpp:5228: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl[abi:se190107] const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000015f9a5fe 17. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000015ed8bfd 18. /build/src/Storages/StorageReplicatedMergeTree.cpp:2514: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x0000000015ec9aab 19. /build/src/Storages/StorageReplicatedMergeTree.cpp:2349: DB::StorageReplicatedMergeTree::executeLogEntry(DB::ReplicatedMergeTreeLogEntry&) @ 0x0000000015eba91b 20. /build/src/Storages/StorageReplicatedMergeTree.cpp:3876: bool std::__function::__policy_invoker&)>::__call_impl[abi:se190107])::$_1, bool (std::shared_ptr&)>>(std::__function::__policy_storage const*, std::shared_ptr&) @ 0x0000000015f9837e 21. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000165d6fc3 22. /build/src/Storages/StorageReplicatedMergeTree.cpp:3872: DB::StorageReplicatedMergeTree::processQueueEntry(std::shared_ptr) @ 0x0000000015efc18a 23. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001624c1b2 24. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000162f9c70 25. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x00000000162fa55a 26. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc6653 27. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000000fccc4c3 28. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc3d92 29. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fcca080 30. ? @ 0x00007fbc6213eac3 31. ? @ 0x00007fbc621d0850 (version 25.3.6.10636.altinitytest (altinity build)) 2025.07.28 11:57:24.152726 [ 3977 ] {} test_13.rmt2 (7f9b740d-015c-470e-8cc6-8ba33be0dc63): auto DB::StorageReplicatedMergeTree::processQueueEntry(ReplicatedMergeTreeQueue::SelectedEntryPtr)::(anonymous class)::operator()(LogEntryPtr &) const: Code: 86. DB::HTTPException: Received error from remote server http://146b4357c08d:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Ftest%2F01165%2Ftest_13%2Frmt%2Freplicas%2F1&part=20250728_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.6.10636.altinitytest (altinity build)) '. (RECEIVED_ERROR_FROM_REMOTE_IO_SERVER), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.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 const&, int&&, String const&, unsigned long&&, String const&) @ 0x000000000feda8d9 4. /build/src/IO/HTTPCommon.cpp:104: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x000000000feda6e2 5. /build/src/IO/HTTPCommon.cpp:93: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x000000000feda537 6. /build/src/IO/ReadWriteBufferFromHTTP.cpp:277: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x000000001184a4c4 7. /build/src/IO/ReadWriteBufferFromHTTP.cpp:285: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x000000001184a615 8. /build/src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x000000001184ae59 9. /build/src/IO/ReadWriteBufferFromHTTP.cpp:472: void std::__function::__policy_invoker::__call_impl[abi:se190107]>(std::__function::__policy_storage const*) @ 0x000000001184cedd 10. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001184858b 11. /build/src/IO/ReadWriteBufferFromHTTP.cpp:465: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x000000001184bf0b 12. /build/src/IO/ReadBuffer.h:60: DB::ReadBuffer::next() @ 0x000000000a148c7b 13. /build/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) @ 0x0000000011849fb2 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]>&)>&, 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&) @ 0x0000000011841980 15. /build/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) @ 0x000000001621208e 16. /build/src/Storages/StorageReplicatedMergeTree.cpp:5228: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl[abi:se190107] const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000015f9a5fe 17. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000015ed8bfd 18. /build/src/Storages/StorageReplicatedMergeTree.cpp:2514: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x0000000015ec9aab 19. /build/src/Storages/StorageReplicatedMergeTree.cpp:2349: DB::StorageReplicatedMergeTree::executeLogEntry(DB::ReplicatedMergeTreeLogEntry&) @ 0x0000000015eba91b 20. /build/src/Storages/StorageReplicatedMergeTree.cpp:3876: bool std::__function::__policy_invoker&)>::__call_impl[abi:se190107])::$_1, bool (std::shared_ptr&)>>(std::__function::__policy_storage const*, std::shared_ptr&) @ 0x0000000015f9837e 21. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000165d6fc3 22. /build/src/Storages/StorageReplicatedMergeTree.cpp:3872: DB::StorageReplicatedMergeTree::processQueueEntry(std::shared_ptr) @ 0x0000000015efc18a 23. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001624c1b2 24. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000162f9c70 25. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x00000000162fa55a 26. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc6653 27. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000000fccc4c3 28. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc3d92 29. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fcca080 30. ? @ 0x00007fbc6213eac3 31. ? @ 0x00007fbc621d0850 (version 25.3.6.10636.altinitytest (altinity build)) 2025.07.28 11:57:25.154354 [ 3976 ] {} test_13.rmt2 (7f9b740d-015c-470e-8cc6-8ba33be0dc63): auto DB::StorageReplicatedMergeTree::processQueueEntry(ReplicatedMergeTreeQueue::SelectedEntryPtr)::(anonymous class)::operator()(LogEntryPtr &) const: Code: 86. DB::HTTPException: Received error from remote server http://146b4357c08d:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Ftest%2F01165%2Ftest_13%2Frmt%2Freplicas%2F1&part=20250728_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.6.10636.altinitytest (altinity build)) '. (RECEIVED_ERROR_FROM_REMOTE_IO_SERVER), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.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 const&, int&&, String const&, unsigned long&&, String const&) @ 0x000000000feda8d9 4. /build/src/IO/HTTPCommon.cpp:104: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x000000000feda6e2 5. /build/src/IO/HTTPCommon.cpp:93: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x000000000feda537 6. /build/src/IO/ReadWriteBufferFromHTTP.cpp:277: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x000000001184a4c4 7. /build/src/IO/ReadWriteBufferFromHTTP.cpp:285: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x000000001184a615 8. /build/src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x000000001184ae59 9. /build/src/IO/ReadWriteBufferFromHTTP.cpp:472: void std::__function::__policy_invoker::__call_impl[abi:se190107]>(std::__function::__policy_storage const*) @ 0x000000001184cedd 10. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001184858b 11. /build/src/IO/ReadWriteBufferFromHTTP.cpp:465: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x000000001184bf0b 12. /build/src/IO/ReadBuffer.h:60: DB::ReadBuffer::next() @ 0x000000000a148c7b 13. /build/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) @ 0x0000000011849fb2 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]>&)>&, 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&) @ 0x0000000011841980 15. /build/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) @ 0x000000001621208e 16. /build/src/Storages/StorageReplicatedMergeTree.cpp:5228: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl[abi:se190107] const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000015f9a5fe 17. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000015ed8bfd 18. /build/src/Storages/StorageReplicatedMergeTree.cpp:2514: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x0000000015ec9aab 19. /build/src/Storages/StorageReplicatedMergeTree.cpp:2349: DB::StorageReplicatedMergeTree::executeLogEntry(DB::ReplicatedMergeTreeLogEntry&) @ 0x0000000015eba91b 20. /build/src/Storages/StorageReplicatedMergeTree.cpp:3876: bool std::__function::__policy_invoker&)>::__call_impl[abi:se190107])::$_1, bool (std::shared_ptr&)>>(std::__function::__policy_storage const*, std::shared_ptr&) @ 0x0000000015f9837e 21. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000165d6fc3 22. /build/src/Storages/StorageReplicatedMergeTree.cpp:3872: DB::StorageReplicatedMergeTree::processQueueEntry(std::shared_ptr) @ 0x0000000015efc18a 23. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001624c1b2 24. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000162f9c70 25. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x00000000162fa55a 26. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc6653 27. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000000fccc4c3 28. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc3d92 29. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fcca080 30. ? @ 0x00007fbc6213eac3 31. ? @ 0x00007fbc621d0850 (version 25.3.6.10636.altinitytest (altinity build)) 2025.07.28 11:57:25.334670 [ 3967 ] {} test_13.rmt2 (7f9b740d-015c-470e-8cc6-8ba33be0dc63): auto DB::StorageReplicatedMergeTree::processQueueEntry(ReplicatedMergeTreeQueue::SelectedEntryPtr)::(anonymous class)::operator()(LogEntryPtr &) const: Code: 86. DB::HTTPException: Received error from remote server http://146b4357c08d:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Ftest%2F01165%2Ftest_13%2Frmt%2Freplicas%2F1&part=20250728_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.6.10636.altinitytest (altinity build)) '. (RECEIVED_ERROR_FROM_REMOTE_IO_SERVER), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.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 const&, int&&, String const&, unsigned long&&, String const&) @ 0x000000000feda8d9 4. /build/src/IO/HTTPCommon.cpp:104: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x000000000feda6e2 5. /build/src/IO/HTTPCommon.cpp:93: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x000000000feda537 6. /build/src/IO/ReadWriteBufferFromHTTP.cpp:277: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x000000001184a4c4 7. /build/src/IO/ReadWriteBufferFromHTTP.cpp:285: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x000000001184a615 8. /build/src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x000000001184ae59 9. /build/src/IO/ReadWriteBufferFromHTTP.cpp:472: void std::__function::__policy_invoker::__call_impl[abi:se190107]>(std::__function::__policy_storage const*) @ 0x000000001184cedd 10. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001184858b 11. /build/src/IO/ReadWriteBufferFromHTTP.cpp:465: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x000000001184bf0b 12. /build/src/IO/ReadBuffer.h:60: DB::ReadBuffer::next() @ 0x000000000a148c7b 13. /build/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) @ 0x0000000011849fb2 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]>&)>&, 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&) @ 0x0000000011841980 15. /build/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) @ 0x000000001621208e 16. /build/src/Storages/StorageReplicatedMergeTree.cpp:5228: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl[abi:se190107] const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000015f9a5fe 17. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000015ed8bfd 18. /build/src/Storages/StorageReplicatedMergeTree.cpp:2514: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x0000000015ec9aab 19. /build/src/Storages/StorageReplicatedMergeTree.cpp:2349: DB::StorageReplicatedMergeTree::executeLogEntry(DB::ReplicatedMergeTreeLogEntry&) @ 0x0000000015eba91b 20. /build/src/Storages/StorageReplicatedMergeTree.cpp:3876: bool std::__function::__policy_invoker&)>::__call_impl[abi:se190107])::$_1, bool (std::shared_ptr&)>>(std::__function::__policy_storage const*, std::shared_ptr&) @ 0x0000000015f9837e 21. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000165d6fc3 22. /build/src/Storages/StorageReplicatedMergeTree.cpp:3872: DB::StorageReplicatedMergeTree::processQueueEntry(std::shared_ptr) @ 0x0000000015efc18a 23. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001624c1b2 24. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000162f9c70 25. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x00000000162fa55a 26. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc6653 27. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000000fccc4c3 28. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc3d92 29. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fcca080 30. ? @ 0x00007fbc6213eac3 31. ? @ 0x00007fbc621d0850 (version 25.3.6.10636.altinitytest (altinity build)) 2025.07.28 11:57:25.576331 [ 3960 ] {} test_13.rmt2 (7f9b740d-015c-470e-8cc6-8ba33be0dc63): auto DB::StorageReplicatedMergeTree::processQueueEntry(ReplicatedMergeTreeQueue::SelectedEntryPtr)::(anonymous class)::operator()(LogEntryPtr &) const: Code: 86. DB::HTTPException: Received error from remote server http://146b4357c08d:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Ftest%2F01165%2Ftest_13%2Frmt%2Freplicas%2F1&part=20250728_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.6.10636.altinitytest (altinity build)) '. (RECEIVED_ERROR_FROM_REMOTE_IO_SERVER), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.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 const&, int&&, String const&, unsigned long&&, String const&) @ 0x000000000feda8d9 4. /build/src/IO/HTTPCommon.cpp:104: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x000000000feda6e2 5. /build/src/IO/HTTPCommon.cpp:93: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x000000000feda537 6. /build/src/IO/ReadWriteBufferFromHTTP.cpp:277: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x000000001184a4c4 7. /build/src/IO/ReadWriteBufferFromHTTP.cpp:285: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x000000001184a615 8. /build/src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x000000001184ae59 9. /build/src/IO/ReadWriteBufferFromHTTP.cpp:472: void std::__function::__policy_invoker::__call_impl[abi:se190107]>(std::__function::__policy_storage const*) @ 0x000000001184cedd 10. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001184858b 11. /build/src/IO/ReadWriteBufferFromHTTP.cpp:465: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x000000001184bf0b 12. /build/src/IO/ReadBuffer.h:60: DB::ReadBuffer::next() @ 0x000000000a148c7b 13. /build/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) @ 0x0000000011849fb2 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]>&)>&, 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&) @ 0x0000000011841980 15. /build/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) @ 0x000000001621208e 16. /build/src/Storages/StorageReplicatedMergeTree.cpp:5228: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl[abi:se190107] const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000015f9a5fe 17. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000015ed8bfd 18. /build/src/Storages/StorageReplicatedMergeTree.cpp:2514: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x0000000015ec9aab 19. /build/src/Storages/StorageReplicatedMergeTree.cpp:2349: DB::StorageReplicatedMergeTree::executeLogEntry(DB::ReplicatedMergeTreeLogEntry&) @ 0x0000000015eba91b 20. /build/src/Storages/StorageReplicatedMergeTree.cpp:3876: bool std::__function::__policy_invoker&)>::__call_impl[abi:se190107])::$_1, bool (std::shared_ptr&)>>(std::__function::__policy_storage const*, std::shared_ptr&) @ 0x0000000015f9837e 21. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000165d6fc3 22. /build/src/Storages/StorageReplicatedMergeTree.cpp:3872: DB::StorageReplicatedMergeTree::processQueueEntry(std::shared_ptr) @ 0x0000000015efc18a 23. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001624c1b2 24. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000162f9c70 25. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x00000000162fa55a 26. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc6653 27. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000000fccc4c3 28. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc3d92 29. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fcca080 30. ? @ 0x00007fbc6213eac3 31. ? @ 0x00007fbc621d0850 (version 25.3.6.10636.altinitytest (altinity build)) 2025.07.28 11:57:25.966492 [ 3965 ] {} test_13.rmt2 (7f9b740d-015c-470e-8cc6-8ba33be0dc63): auto DB::StorageReplicatedMergeTree::processQueueEntry(ReplicatedMergeTreeQueue::SelectedEntryPtr)::(anonymous class)::operator()(LogEntryPtr &) const: Code: 86. DB::HTTPException: Received error from remote server http://146b4357c08d:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Ftest%2F01165%2Ftest_13%2Frmt%2Freplicas%2F1&part=20250728_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.6.10636.altinitytest (altinity build)) '. (RECEIVED_ERROR_FROM_REMOTE_IO_SERVER), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.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 const&, int&&, String const&, unsigned long&&, String const&) @ 0x000000000feda8d9 4. /build/src/IO/HTTPCommon.cpp:104: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x000000000feda6e2 5. /build/src/IO/HTTPCommon.cpp:93: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x000000000feda537 6. /build/src/IO/ReadWriteBufferFromHTTP.cpp:277: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x000000001184a4c4 7. /build/src/IO/ReadWriteBufferFromHTTP.cpp:285: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x000000001184a615 8. /build/src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x000000001184ae59 9. /build/src/IO/ReadWriteBufferFromHTTP.cpp:472: void std::__function::__policy_invoker::__call_impl[abi:se190107]>(std::__function::__policy_storage const*) @ 0x000000001184cedd 10. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001184858b 11. /build/src/IO/ReadWriteBufferFromHTTP.cpp:465: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x000000001184bf0b 12. /build/src/IO/ReadBuffer.h:60: DB::ReadBuffer::next() @ 0x000000000a148c7b 13. /build/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) @ 0x0000000011849fb2 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]>&)>&, 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&) @ 0x0000000011841980 15. /build/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) @ 0x000000001621208e 16. /build/src/Storages/StorageReplicatedMergeTree.cpp:5228: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl[abi:se190107] const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000015f9a5fe 17. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000015ed8bfd 18. /build/src/Storages/StorageReplicatedMergeTree.cpp:2514: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x0000000015ec9aab 19. /build/src/Storages/StorageReplicatedMergeTree.cpp:2349: DB::StorageReplicatedMergeTree::executeLogEntry(DB::ReplicatedMergeTreeLogEntry&) @ 0x0000000015eba91b 20. /build/src/Storages/StorageReplicatedMergeTree.cpp:3876: bool std::__function::__policy_invoker&)>::__call_impl[abi:se190107])::$_1, bool (std::shared_ptr&)>>(std::__function::__policy_storage const*, std::shared_ptr&) @ 0x0000000015f9837e 21. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000165d6fc3 22. /build/src/Storages/StorageReplicatedMergeTree.cpp:3872: DB::StorageReplicatedMergeTree::processQueueEntry(std::shared_ptr) @ 0x0000000015efc18a 23. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001624c1b2 24. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000162f9c70 25. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x00000000162fa55a 26. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc6653 27. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000000fccc4c3 28. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc3d92 29. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fcca080 30. ? @ 0x00007fbc6213eac3 31. ? @ 0x00007fbc621d0850 (version 25.3.6.10636.altinitytest (altinity build)) 2025.07.28 11:57:27.065033 [ 3961 ] {} test_13.rmt2 (7f9b740d-015c-470e-8cc6-8ba33be0dc63): auto DB::StorageReplicatedMergeTree::processQueueEntry(ReplicatedMergeTreeQueue::SelectedEntryPtr)::(anonymous class)::operator()(LogEntryPtr &) const: Code: 86. DB::HTTPException: Received error from remote server http://146b4357c08d:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Ftest%2F01165%2Ftest_13%2Frmt%2Freplicas%2F1&part=20250728_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.6.10636.altinitytest (altinity build)) '. (RECEIVED_ERROR_FROM_REMOTE_IO_SERVER), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.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 const&, int&&, String const&, unsigned long&&, String const&) @ 0x000000000feda8d9 4. /build/src/IO/HTTPCommon.cpp:104: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x000000000feda6e2 5. /build/src/IO/HTTPCommon.cpp:93: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x000000000feda537 6. /build/src/IO/ReadWriteBufferFromHTTP.cpp:277: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x000000001184a4c4 7. /build/src/IO/ReadWriteBufferFromHTTP.cpp:285: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x000000001184a615 8. /build/src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x000000001184ae59 9. /build/src/IO/ReadWriteBufferFromHTTP.cpp:472: void std::__function::__policy_invoker::__call_impl[abi:se190107]>(std::__function::__policy_storage const*) @ 0x000000001184cedd 10. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001184858b 11. /build/src/IO/ReadWriteBufferFromHTTP.cpp:465: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x000000001184bf0b 12. /build/src/IO/ReadBuffer.h:60: DB::ReadBuffer::next() @ 0x000000000a148c7b 13. /build/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) @ 0x0000000011849fb2 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]>&)>&, 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&) @ 0x0000000011841980 15. /build/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) @ 0x000000001621208e 16. /build/src/Storages/StorageReplicatedMergeTree.cpp:5228: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl[abi:se190107] const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000015f9a5fe 17. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000015ed8bfd 18. /build/src/Storages/StorageReplicatedMergeTree.cpp:2514: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x0000000015ec9aab 19. /build/src/Storages/StorageReplicatedMergeTree.cpp:2349: DB::StorageReplicatedMergeTree::executeLogEntry(DB::ReplicatedMergeTreeLogEntry&) @ 0x0000000015eba91b 20. /build/src/Storages/StorageReplicatedMergeTree.cpp:3876: bool std::__function::__policy_invoker&)>::__call_impl[abi:se190107])::$_1, bool (std::shared_ptr&)>>(std::__function::__policy_storage const*, std::shared_ptr&) @ 0x0000000015f9837e 21. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000165d6fc3 22. /build/src/Storages/StorageReplicatedMergeTree.cpp:3872: DB::StorageReplicatedMergeTree::processQueueEntry(std::shared_ptr) @ 0x0000000015efc18a 23. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001624c1b2 24. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000162f9c70 25. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x00000000162fa55a 26. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc6653 27. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000000fccc4c3 28. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc3d92 29. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fcca080 30. ? @ 0x00007fbc6213eac3 31. ? @ 0x00007fbc621d0850 (version 25.3.6.10636.altinitytest (altinity build)) 2025.07.28 11:57:28.003009 [ 33888 ] {} test_cirghare.limited_merge_table (2894c2d8-fad3-457c-9b81-752d4ac14e63): dropAllData: got exception removing parts from disk, removing successfully removed parts from memory. 2025.07.28 11:57:28.058488 [ 33888 ] {} DatabaseCatalog: Cannot drop table test_cirghare.limited_merge_table (2894c2d8-fad3-457c-9b81-752d4ac14e63). Will retry later.: 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. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000fccaeeb 4. /build/src/Common/ThreadPool.cpp:275: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000fccc813 5. /build/src/Common/ThreadPool.cpp:308: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fcc8286 6. /build/src/Common/ThreadPool.cpp:494: ThreadPoolImpl>::scheduleOrThrowOnError(std::function, Priority) @ 0x000000000fcc7a0e 7. /build/src/Common/threadPoolCallbackRunner.h:188: DB::ThreadPoolCallbackRunnerLocal>, std::function>::operator()(std::function&&, Priority, std::optional) @ 0x00000000119df78e 8. /build/src/Storages/MergeTree/MergeTreeData.cpp:2943: DB::MergeTreeData::clearPartsFromFilesystemImplMaybeInParallel(std::vector, std::allocator>> const&, std::unordered_set, std::equal_to, std::allocator>*) @ 0x0000000016327b54 9. /build/src/Storages/MergeTree/MergeTreeData.cpp:2880: DB::MergeTreeData::clearPartsFromFilesystemImpl(std::vector, std::allocator>> const&, bool, std::unordered_set, std::equal_to, std::allocator>*) @ 0x0000000016326c40 10. /build/src/Storages/MergeTree/MergeTreeData.cpp:3286: DB::MergeTreeData::dropAllData() @ 0x000000001632e7c7 11. /build/src/Interpreters/DatabaseCatalog.cpp:1400: DB::DatabaseCatalog::dropTableFinally(DB::DatabaseCatalog::TableMarkedAsDropped const&) @ 0x00000000144fd90e 12. /build/src/Interpreters/DatabaseCatalog.cpp:1323: void std::__function::__policy_invoker::__call_impl[abi:se190107], std::allocator>>)::$_0, void ()>>(std::__function::__policy_storage const*) @ 0x0000000014505fd1 13. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000119e01f0 14. /build/src/Common/threadPoolCallbackRunner.h:178: DB::ThreadPoolCallbackRunnerLocal>, std::function>::operator()(std::function&&, Priority, std::optional)::'lambda'()::operator()() @ 0x00000000119e001b 15. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc6653 16. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000000fccc4c3 17. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc3d92 18. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fcca080 19. ? @ 0x00007fbc6213eac3 20. ? @ 0x00007fbc621d0850 (version 25.3.6.10636.altinitytest (altinity build)) 2025.07.28 11:57:28.090987 [ 3974 ] {} test_13.rmt2 (7f9b740d-015c-470e-8cc6-8ba33be0dc63): auto DB::StorageReplicatedMergeTree::processQueueEntry(ReplicatedMergeTreeQueue::SelectedEntryPtr)::(anonymous class)::operator()(LogEntryPtr &) const: Code: 86. DB::HTTPException: Received error from remote server http://146b4357c08d:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Ftest%2F01165%2Ftest_13%2Frmt%2Freplicas%2F1&part=20250728_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.6.10636.altinitytest (altinity build)) '. (RECEIVED_ERROR_FROM_REMOTE_IO_SERVER), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.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 const&, int&&, String const&, unsigned long&&, String const&) @ 0x000000000feda8d9 4. /build/src/IO/HTTPCommon.cpp:104: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x000000000feda6e2 5. /build/src/IO/HTTPCommon.cpp:93: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x000000000feda537 6. /build/src/IO/ReadWriteBufferFromHTTP.cpp:277: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x000000001184a4c4 7. /build/src/IO/ReadWriteBufferFromHTTP.cpp:285: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x000000001184a615 8. /build/src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x000000001184ae59 9. /build/src/IO/ReadWriteBufferFromHTTP.cpp:472: void std::__function::__policy_invoker::__call_impl[abi:se190107]>(std::__function::__policy_storage const*) @ 0x000000001184cedd 10. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001184858b 11. /build/src/IO/ReadWriteBufferFromHTTP.cpp:465: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x000000001184bf0b 12. /build/src/IO/ReadBuffer.h:60: DB::ReadBuffer::next() @ 0x000000000a148c7b 13. /build/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) @ 0x0000000011849fb2 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]>&)>&, 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&) @ 0x0000000011841980 15. /build/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) @ 0x000000001621208e 16. /build/src/Storages/StorageReplicatedMergeTree.cpp:5228: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl[abi:se190107] const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000015f9a5fe 17. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000015ed8bfd 18. /build/src/Storages/StorageReplicatedMergeTree.cpp:2514: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x0000000015ec9aab 19. /build/src/Storages/StorageReplicatedMergeTree.cpp:2349: DB::StorageReplicatedMergeTree::executeLogEntry(DB::ReplicatedMergeTreeLogEntry&) @ 0x0000000015eba91b 20. /build/src/Storages/StorageReplicatedMergeTree.cpp:3876: bool std::__function::__policy_invoker&)>::__call_impl[abi:se190107])::$_1, bool (std::shared_ptr&)>>(std::__function::__policy_storage const*, std::shared_ptr&) @ 0x0000000015f9837e 21. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000165d6fc3 22. /build/src/Storages/StorageReplicatedMergeTree.cpp:3872: DB::StorageReplicatedMergeTree::processQueueEntry(std::shared_ptr) @ 0x0000000015efc18a 23. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001624c1b2 24. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000162f9c70 25. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x00000000162fa55a 26. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc6653 27. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000000fccc4c3 28. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc3d92 29. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fcca080 30. ? @ 0x00007fbc6213eac3 31. ? @ 0x00007fbc621d0850 (version 25.3.6.10636.altinitytest (altinity build)) 2025.07.28 11:57:29.207354 [ 3977 ] {} test_13.rmt2 (7f9b740d-015c-470e-8cc6-8ba33be0dc63): auto DB::StorageReplicatedMergeTree::processQueueEntry(ReplicatedMergeTreeQueue::SelectedEntryPtr)::(anonymous class)::operator()(LogEntryPtr &) const: Code: 86. DB::HTTPException: Received error from remote server http://146b4357c08d:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Ftest%2F01165%2Ftest_13%2Frmt%2Freplicas%2F1&part=20250728_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.6.10636.altinitytest (altinity build)) '. (RECEIVED_ERROR_FROM_REMOTE_IO_SERVER), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.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 const&, int&&, String const&, unsigned long&&, String const&) @ 0x000000000feda8d9 4. /build/src/IO/HTTPCommon.cpp:104: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x000000000feda6e2 5. /build/src/IO/HTTPCommon.cpp:93: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x000000000feda537 6. /build/src/IO/ReadWriteBufferFromHTTP.cpp:277: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x000000001184a4c4 7. /build/src/IO/ReadWriteBufferFromHTTP.cpp:285: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x000000001184a615 8. /build/src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x000000001184ae59 9. /build/src/IO/ReadWriteBufferFromHTTP.cpp:472: void std::__function::__policy_invoker::__call_impl[abi:se190107]>(std::__function::__policy_storage const*) @ 0x000000001184cedd 10. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001184858b 11. /build/src/IO/ReadWriteBufferFromHTTP.cpp:465: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x000000001184bf0b 12. /build/src/IO/ReadBuffer.h:60: DB::ReadBuffer::next() @ 0x000000000a148c7b 13. /build/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) @ 0x0000000011849fb2 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]>&)>&, 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&) @ 0x0000000011841980 15. /build/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) @ 0x000000001621208e 16. /build/src/Storages/StorageReplicatedMergeTree.cpp:5228: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl[abi:se190107] const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000015f9a5fe 17. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000015ed8bfd 18. /build/src/Storages/StorageReplicatedMergeTree.cpp:2514: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x0000000015ec9aab 19. /build/src/Storages/StorageReplicatedMergeTree.cpp:2349: DB::StorageReplicatedMergeTree::executeLogEntry(DB::ReplicatedMergeTreeLogEntry&) @ 0x0000000015eba91b 20. /build/src/Storages/StorageReplicatedMergeTree.cpp:3876: bool std::__function::__policy_invoker&)>::__call_impl[abi:se190107])::$_1, bool (std::shared_ptr&)>>(std::__function::__policy_storage const*, std::shared_ptr&) @ 0x0000000015f9837e 21. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000165d6fc3 22. /build/src/Storages/StorageReplicatedMergeTree.cpp:3872: DB::StorageReplicatedMergeTree::processQueueEntry(std::shared_ptr) @ 0x0000000015efc18a 23. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001624c1b2 24. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000162f9c70 25. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x00000000162fa55a 26. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc6653 27. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000000fccc4c3 28. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc3d92 29. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fcca080 30. ? @ 0x00007fbc6213eac3 31. ? @ 0x00007fbc621d0850 (version 25.3.6.10636.altinitytest (altinity build)) 2025.07.28 11:57:29.274971 [ 3970 ] {} test_13.rmt2 (7f9b740d-015c-470e-8cc6-8ba33be0dc63): auto DB::StorageReplicatedMergeTree::processQueueEntry(ReplicatedMergeTreeQueue::SelectedEntryPtr)::(anonymous class)::operator()(LogEntryPtr &) const: Code: 86. DB::HTTPException: Received error from remote server http://146b4357c08d:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Ftest%2F01165%2Ftest_13%2Frmt%2Freplicas%2F1&part=20250728_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.6.10636.altinitytest (altinity build)) '. (RECEIVED_ERROR_FROM_REMOTE_IO_SERVER), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.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 const&, int&&, String const&, unsigned long&&, String const&) @ 0x000000000feda8d9 4. /build/src/IO/HTTPCommon.cpp:104: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x000000000feda6e2 5. /build/src/IO/HTTPCommon.cpp:93: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x000000000feda537 6. /build/src/IO/ReadWriteBufferFromHTTP.cpp:277: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x000000001184a4c4 7. /build/src/IO/ReadWriteBufferFromHTTP.cpp:285: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x000000001184a615 8. /build/src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x000000001184ae59 9. /build/src/IO/ReadWriteBufferFromHTTP.cpp:472: void std::__function::__policy_invoker::__call_impl[abi:se190107]>(std::__function::__policy_storage const*) @ 0x000000001184cedd 10. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001184858b 11. /build/src/IO/ReadWriteBufferFromHTTP.cpp:465: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x000000001184bf0b 12. /build/src/IO/ReadBuffer.h:60: DB::ReadBuffer::next() @ 0x000000000a148c7b 13. /build/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) @ 0x0000000011849fb2 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]>&)>&, 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&) @ 0x0000000011841980 15. /build/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) @ 0x000000001621208e 16. /build/src/Storages/StorageReplicatedMergeTree.cpp:5228: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl[abi:se190107] const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000015f9a5fe 17. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000015ed8bfd 18. /build/src/Storages/StorageReplicatedMergeTree.cpp:2514: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x0000000015ec9aab 19. /build/src/Storages/StorageReplicatedMergeTree.cpp:2349: DB::StorageReplicatedMergeTree::executeLogEntry(DB::ReplicatedMergeTreeLogEntry&) @ 0x0000000015eba91b 20. /build/src/Storages/StorageReplicatedMergeTree.cpp:3876: bool std::__function::__policy_invoker&)>::__call_impl[abi:se190107])::$_1, bool (std::shared_ptr&)>>(std::__function::__policy_storage const*, std::shared_ptr&) @ 0x0000000015f9837e 21. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000165d6fc3 22. /build/src/Storages/StorageReplicatedMergeTree.cpp:3872: DB::StorageReplicatedMergeTree::processQueueEntry(std::shared_ptr) @ 0x0000000015efc18a 23. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001624c1b2 24. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000162f9c70 25. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x00000000162fa55a 26. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc6653 27. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000000fccc4c3 28. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc3d92 29. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fcca080 30. ? @ 0x00007fbc6213eac3 31. ? @ 0x00007fbc621d0850 (version 25.3.6.10636.altinitytest (altinity build)) 2025.07.28 11:57:29.692035 [ 3964 ] {} test_13.rmt2 (7f9b740d-015c-470e-8cc6-8ba33be0dc63): auto DB::StorageReplicatedMergeTree::processQueueEntry(ReplicatedMergeTreeQueue::SelectedEntryPtr)::(anonymous class)::operator()(LogEntryPtr &) const: Code: 86. DB::HTTPException: Received error from remote server http://146b4357c08d:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Ftest%2F01165%2Ftest_13%2Frmt%2Freplicas%2F1&part=20250728_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.6.10636.altinitytest (altinity build)) '. (RECEIVED_ERROR_FROM_REMOTE_IO_SERVER), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.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 const&, int&&, String const&, unsigned long&&, String const&) @ 0x000000000feda8d9 4. /build/src/IO/HTTPCommon.cpp:104: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x000000000feda6e2 5. /build/src/IO/HTTPCommon.cpp:93: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x000000000feda537 6. /build/src/IO/ReadWriteBufferFromHTTP.cpp:277: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x000000001184a4c4 7. /build/src/IO/ReadWriteBufferFromHTTP.cpp:285: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x000000001184a615 8. /build/src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x000000001184ae59 9. /build/src/IO/ReadWriteBufferFromHTTP.cpp:472: void std::__function::__policy_invoker::__call_impl[abi:se190107]>(std::__function::__policy_storage const*) @ 0x000000001184cedd 10. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001184858b 11. /build/src/IO/ReadWriteBufferFromHTTP.cpp:465: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x000000001184bf0b 12. /build/src/IO/ReadBuffer.h:60: DB::ReadBuffer::next() @ 0x000000000a148c7b 13. /build/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) @ 0x0000000011849fb2 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]>&)>&, 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&) @ 0x0000000011841980 15. /build/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) @ 0x000000001621208e 16. /build/src/Storages/StorageReplicatedMergeTree.cpp:5228: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl[abi:se190107] const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000015f9a5fe 17. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000015ed8bfd 18. /build/src/Storages/StorageReplicatedMergeTree.cpp:2514: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x0000000015ec9aab 19. /build/src/Storages/StorageReplicatedMergeTree.cpp:2349: DB::StorageReplicatedMergeTree::executeLogEntry(DB::ReplicatedMergeTreeLogEntry&) @ 0x0000000015eba91b 20. /build/src/Storages/StorageReplicatedMergeTree.cpp:3876: bool std::__function::__policy_invoker&)>::__call_impl[abi:se190107])::$_1, bool (std::shared_ptr&)>>(std::__function::__policy_storage const*, std::shared_ptr&) @ 0x0000000015f9837e 21. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000165d6fc3 22. /build/src/Storages/StorageReplicatedMergeTree.cpp:3872: DB::StorageReplicatedMergeTree::processQueueEntry(std::shared_ptr) @ 0x0000000015efc18a 23. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001624c1b2 24. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000162f9c70 25. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x00000000162fa55a 26. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc6653 27. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000000fccc4c3 28. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc3d92 29. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fcca080 30. ? @ 0x00007fbc6213eac3 31. ? @ 0x00007fbc621d0850 (version 25.3.6.10636.altinitytest (altinity build)) 2025.07.28 11:57:30.580528 [ 3966 ] {} test_13.rmt2 (7f9b740d-015c-470e-8cc6-8ba33be0dc63): auto DB::StorageReplicatedMergeTree::processQueueEntry(ReplicatedMergeTreeQueue::SelectedEntryPtr)::(anonymous class)::operator()(LogEntryPtr &) const: Code: 86. DB::HTTPException: Received error from remote server http://146b4357c08d:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Ftest%2F01165%2Ftest_13%2Frmt%2Freplicas%2F1&part=20250728_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.6.10636.altinitytest (altinity build)) '. (RECEIVED_ERROR_FROM_REMOTE_IO_SERVER), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.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 const&, int&&, String const&, unsigned long&&, String const&) @ 0x000000000feda8d9 4. /build/src/IO/HTTPCommon.cpp:104: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x000000000feda6e2 5. /build/src/IO/HTTPCommon.cpp:93: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x000000000feda537 6. /build/src/IO/ReadWriteBufferFromHTTP.cpp:277: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x000000001184a4c4 7. /build/src/IO/ReadWriteBufferFromHTTP.cpp:285: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x000000001184a615 8. /build/src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x000000001184ae59 9. /build/src/IO/ReadWriteBufferFromHTTP.cpp:472: void std::__function::__policy_invoker::__call_impl[abi:se190107]>(std::__function::__policy_storage const*) @ 0x000000001184cedd 10. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001184858b 11. /build/src/IO/ReadWriteBufferFromHTTP.cpp:465: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x000000001184bf0b 12. /build/src/IO/ReadBuffer.h:60: DB::ReadBuffer::next() @ 0x000000000a148c7b 13. /build/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) @ 0x0000000011849fb2 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]>&)>&, 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&) @ 0x0000000011841980 15. /build/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) @ 0x000000001621208e 16. /build/src/Storages/StorageReplicatedMergeTree.cpp:5228: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl[abi:se190107] const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000015f9a5fe 17. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000015ed8bfd 18. /build/src/Storages/StorageReplicatedMergeTree.cpp:2514: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x0000000015ec9aab 19. /build/src/Storages/StorageReplicatedMergeTree.cpp:2349: DB::StorageReplicatedMergeTree::executeLogEntry(DB::ReplicatedMergeTreeLogEntry&) @ 0x0000000015eba91b 20. /build/src/Storages/StorageReplicatedMergeTree.cpp:3876: bool std::__function::__policy_invoker&)>::__call_impl[abi:se190107])::$_1, bool (std::shared_ptr&)>>(std::__function::__policy_storage const*, std::shared_ptr&) @ 0x0000000015f9837e 21. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000165d6fc3 22. /build/src/Storages/StorageReplicatedMergeTree.cpp:3872: DB::StorageReplicatedMergeTree::processQueueEntry(std::shared_ptr) @ 0x0000000015efc18a 23. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001624c1b2 24. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000162f9c70 25. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x00000000162fa55a 26. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc6653 27. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000000fccc4c3 28. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc3d92 29. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fcca080 30. ? @ 0x00007fbc6213eac3 31. ? @ 0x00007fbc621d0850 (version 25.3.6.10636.altinitytest (altinity build)) 2025.07.28 11:57:31.733523 [ 3967 ] {} test_13.rmt2 (7f9b740d-015c-470e-8cc6-8ba33be0dc63): auto DB::StorageReplicatedMergeTree::processQueueEntry(ReplicatedMergeTreeQueue::SelectedEntryPtr)::(anonymous class)::operator()(LogEntryPtr &) const: Code: 86. DB::HTTPException: Received error from remote server http://146b4357c08d:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Ftest%2F01165%2Ftest_13%2Frmt%2Freplicas%2F1&part=20250728_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.6.10636.altinitytest (altinity build)) '. (RECEIVED_ERROR_FROM_REMOTE_IO_SERVER), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.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 const&, int&&, String const&, unsigned long&&, String const&) @ 0x000000000feda8d9 4. /build/src/IO/HTTPCommon.cpp:104: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x000000000feda6e2 5. /build/src/IO/HTTPCommon.cpp:93: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x000000000feda537 6. /build/src/IO/ReadWriteBufferFromHTTP.cpp:277: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x000000001184a4c4 7. /build/src/IO/ReadWriteBufferFromHTTP.cpp:285: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x000000001184a615 8. /build/src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x000000001184ae59 9. /build/src/IO/ReadWriteBufferFromHTTP.cpp:472: void std::__function::__policy_invoker::__call_impl[abi:se190107]>(std::__function::__policy_storage const*) @ 0x000000001184cedd 10. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001184858b 11. /build/src/IO/ReadWriteBufferFromHTTP.cpp:465: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x000000001184bf0b 12. /build/src/IO/ReadBuffer.h:60: DB::ReadBuffer::next() @ 0x000000000a148c7b 13. /build/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) @ 0x0000000011849fb2 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]>&)>&, 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&) @ 0x0000000011841980 15. /build/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) @ 0x000000001621208e 16. /build/src/Storages/StorageReplicatedMergeTree.cpp:5228: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl[abi:se190107] const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000015f9a5fe 17. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000015ed8bfd 18. /build/src/Storages/StorageReplicatedMergeTree.cpp:2514: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x0000000015ec9aab 19. /build/src/Storages/StorageReplicatedMergeTree.cpp:2349: DB::StorageReplicatedMergeTree::executeLogEntry(DB::ReplicatedMergeTreeLogEntry&) @ 0x0000000015eba91b 20. /build/src/Storages/StorageReplicatedMergeTree.cpp:3876: bool std::__function::__policy_invoker&)>::__call_impl[abi:se190107])::$_1, bool (std::shared_ptr&)>>(std::__function::__policy_storage const*, std::shared_ptr&) @ 0x0000000015f9837e 21. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000165d6fc3 22. /build/src/Storages/StorageReplicatedMergeTree.cpp:3872: DB::StorageReplicatedMergeTree::processQueueEntry(std::shared_ptr) @ 0x0000000015efc18a 23. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001624c1b2 24. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000162f9c70 25. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x00000000162fa55a 26. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc6653 27. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000000fccc4c3 28. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc3d92 29. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fcca080 30. ? @ 0x00007fbc6213eac3 31. ? @ 0x00007fbc621d0850 (version 25.3.6.10636.altinitytest (altinity build)) 2025.07.28 11:57:32.340024 [ 3972 ] {} test_13.rmt2 (7f9b740d-015c-470e-8cc6-8ba33be0dc63): auto DB::StorageReplicatedMergeTree::processQueueEntry(ReplicatedMergeTreeQueue::SelectedEntryPtr)::(anonymous class)::operator()(LogEntryPtr &) const: Code: 86. DB::HTTPException: Received error from remote server http://146b4357c08d:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Ftest%2F01165%2Ftest_13%2Frmt%2Freplicas%2F1&part=20250728_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.6.10636.altinitytest (altinity build)) '. (RECEIVED_ERROR_FROM_REMOTE_IO_SERVER), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.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 const&, int&&, String const&, unsigned long&&, String const&) @ 0x000000000feda8d9 4. /build/src/IO/HTTPCommon.cpp:104: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x000000000feda6e2 5. /build/src/IO/HTTPCommon.cpp:93: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x000000000feda537 6. /build/src/IO/ReadWriteBufferFromHTTP.cpp:277: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x000000001184a4c4 7. /build/src/IO/ReadWriteBufferFromHTTP.cpp:285: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x000000001184a615 8. /build/src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x000000001184ae59 9. /build/src/IO/ReadWriteBufferFromHTTP.cpp:472: void std::__function::__policy_invoker::__call_impl[abi:se190107]>(std::__function::__policy_storage const*) @ 0x000000001184cedd 10. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001184858b 11. /build/src/IO/ReadWriteBufferFromHTTP.cpp:465: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x000000001184bf0b 12. /build/src/IO/ReadBuffer.h:60: DB::ReadBuffer::next() @ 0x000000000a148c7b 13. /build/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) @ 0x0000000011849fb2 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]>&)>&, 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&) @ 0x0000000011841980 15. /build/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) @ 0x000000001621208e 16. /build/src/Storages/StorageReplicatedMergeTree.cpp:5228: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl[abi:se190107] const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000015f9a5fe 17. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000015ed8bfd 18. /build/src/Storages/StorageReplicatedMergeTree.cpp:2514: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x0000000015ec9aab 19. /build/src/Storages/StorageReplicatedMergeTree.cpp:2349: DB::StorageReplicatedMergeTree::executeLogEntry(DB::ReplicatedMergeTreeLogEntry&) @ 0x0000000015eba91b 20. /build/src/Storages/StorageReplicatedMergeTree.cpp:3876: bool std::__function::__policy_invoker&)>::__call_impl[abi:se190107])::$_1, bool (std::shared_ptr&)>>(std::__function::__policy_storage const*, std::shared_ptr&) @ 0x0000000015f9837e 21. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000165d6fc3 22. /build/src/Storages/StorageReplicatedMergeTree.cpp:3872: DB::StorageReplicatedMergeTree::processQueueEntry(std::shared_ptr) @ 0x0000000015efc18a 23. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001624c1b2 24. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000162f9c70 25. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x00000000162fa55a 26. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc6653 27. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000000fccc4c3 28. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc3d92 29. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fcca080 30. ? @ 0x00007fbc6213eac3 31. ? @ 0x00007fbc621d0850 (version 25.3.6.10636.altinitytest (altinity build)) 2025.07.28 11:57:33.385196 [ 17611 ] {} 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. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception>&, String>(int, FormatStringHelperImpl>&>::type, std::type_identity::type>, std::basic_string_view>&, String&&) @ 0x000000001385a5eb 4. /build/src/Access/SettingsConstraints.cpp:376: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000013859b18 5. /build/src/Access/SettingsConstraints.cpp:300: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000013858faf 6. /build/src/Access/SettingsConstraints.cpp:209: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000013859223 7. /build/src/Interpreters/Context.cpp:2690: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000014436134 8. /build/src/Interpreters/Context.cpp:2729: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x000000001443662b 9. /build/src/Server/HTTPHandler.cpp:457: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000001686d165 10. /build/src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x0000000016870807 11. /build/src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x0000000016907e99 12. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 13. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 14. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 15. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 16. ? @ 0x00007fbc6213eac3 17. ? @ 0x00007fbc621d0850 (version 25.3.6.10636.altinitytest (altinity build)) 2025.07.28 11:57:33.387405 [ 3976 ] {} test_13.rmt2 (7f9b740d-015c-470e-8cc6-8ba33be0dc63): auto DB::StorageReplicatedMergeTree::processQueueEntry(ReplicatedMergeTreeQueue::SelectedEntryPtr)::(anonymous class)::operator()(LogEntryPtr &) const: Code: 86. DB::HTTPException: Received error from remote server http://146b4357c08d:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Ftest%2F01165%2Ftest_13%2Frmt%2Freplicas%2F1&part=20250728_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.6.10636.altinitytest (altinity build)) '. (RECEIVED_ERROR_FROM_REMOTE_IO_SERVER), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.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 const&, int&&, String const&, unsigned long&&, String const&) @ 0x000000000feda8d9 4. /build/src/IO/HTTPCommon.cpp:104: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x000000000feda6e2 5. /build/src/IO/HTTPCommon.cpp:93: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x000000000feda537 6. /build/src/IO/ReadWriteBufferFromHTTP.cpp:277: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x000000001184a4c4 7. /build/src/IO/ReadWriteBufferFromHTTP.cpp:285: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x000000001184a615 8. /build/src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x000000001184ae59 9. /build/src/IO/ReadWriteBufferFromHTTP.cpp:472: void std::__function::__policy_invoker::__call_impl[abi:se190107]>(std::__function::__policy_storage const*) @ 0x000000001184cedd 10. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001184858b 11. /build/src/IO/ReadWriteBufferFromHTTP.cpp:465: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x000000001184bf0b 12. /build/src/IO/ReadBuffer.h:60: DB::ReadBuffer::next() @ 0x000000000a148c7b 13. /build/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) @ 0x0000000011849fb2 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]>&)>&, 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&) @ 0x0000000011841980 15. /build/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) @ 0x000000001621208e 16. /build/src/Storages/StorageReplicatedMergeTree.cpp:5228: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl[abi:se190107] const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000015f9a5fe 17. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000015ed8bfd 18. /build/src/Storages/StorageReplicatedMergeTree.cpp:2514: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x0000000015ec9aab 19. /build/src/Storages/StorageReplicatedMergeTree.cpp:2349: DB::StorageReplicatedMergeTree::executeLogEntry(DB::ReplicatedMergeTreeLogEntry&) @ 0x0000000015eba91b 20. /build/src/Storages/StorageReplicatedMergeTree.cpp:3876: bool std::__function::__policy_invoker&)>::__call_impl[abi:se190107])::$_1, bool (std::shared_ptr&)>>(std::__function::__policy_storage const*, std::shared_ptr&) @ 0x0000000015f9837e 21. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000165d6fc3 22. /build/src/Storages/StorageReplicatedMergeTree.cpp:3872: DB::StorageReplicatedMergeTree::processQueueEntry(std::shared_ptr) @ 0x0000000015efc18a 23. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001624c1b2 24. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000162f9c70 25. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x00000000162fa55a 26. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc6653 27. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000000fccc4c3 28. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc3d92 29. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fcca080 30. ? @ 0x00007fbc6213eac3 31. ? @ 0x00007fbc621d0850 (version 25.3.6.10636.altinitytest (altinity build)) 2025.07.28 11:57:34.116626 [ 3968 ] {} test_13.rmt2 (7f9b740d-015c-470e-8cc6-8ba33be0dc63): auto DB::StorageReplicatedMergeTree::processQueueEntry(ReplicatedMergeTreeQueue::SelectedEntryPtr)::(anonymous class)::operator()(LogEntryPtr &) const: Code: 86. DB::HTTPException: Received error from remote server http://146b4357c08d:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Ftest%2F01165%2Ftest_13%2Frmt%2Freplicas%2F1&part=20250728_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.6.10636.altinitytest (altinity build)) '. (RECEIVED_ERROR_FROM_REMOTE_IO_SERVER), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.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 const&, int&&, String const&, unsigned long&&, String const&) @ 0x000000000feda8d9 4. /build/src/IO/HTTPCommon.cpp:104: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x000000000feda6e2 5. /build/src/IO/HTTPCommon.cpp:93: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x000000000feda537 6. /build/src/IO/ReadWriteBufferFromHTTP.cpp:277: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x000000001184a4c4 7. /build/src/IO/ReadWriteBufferFromHTTP.cpp:285: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x000000001184a615 8. /build/src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x000000001184ae59 9. /build/src/IO/ReadWriteBufferFromHTTP.cpp:472: void std::__function::__policy_invoker::__call_impl[abi:se190107]>(std::__function::__policy_storage const*) @ 0x000000001184cedd 10. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001184858b 11. /build/src/IO/ReadWriteBufferFromHTTP.cpp:465: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x000000001184bf0b 12. /build/src/IO/ReadBuffer.h:60: DB::ReadBuffer::next() @ 0x000000000a148c7b 13. /build/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) @ 0x0000000011849fb2 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]>&)>&, 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&) @ 0x0000000011841980 15. /build/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) @ 0x000000001621208e 16. /build/src/Storages/StorageReplicatedMergeTree.cpp:5228: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl[abi:se190107] const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000015f9a5fe 17. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000015ed8bfd 18. /build/src/Storages/StorageReplicatedMergeTree.cpp:2514: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x0000000015ec9aab 19. /build/src/Storages/StorageReplicatedMergeTree.cpp:2349: DB::StorageReplicatedMergeTree::executeLogEntry(DB::ReplicatedMergeTreeLogEntry&) @ 0x0000000015eba91b 20. /build/src/Storages/StorageReplicatedMergeTree.cpp:3876: bool std::__function::__policy_invoker&)>::__call_impl[abi:se190107])::$_1, bool (std::shared_ptr&)>>(std::__function::__policy_storage const*, std::shared_ptr&) @ 0x0000000015f9837e 21. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000165d6fc3 22. /build/src/Storages/StorageReplicatedMergeTree.cpp:3872: DB::StorageReplicatedMergeTree::processQueueEntry(std::shared_ptr) @ 0x0000000015efc18a 23. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001624c1b2 24. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000162f9c70 25. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x00000000162fa55a 26. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc6653 27. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000000fccc4c3 28. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc3d92 29. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fcca080 30. ? @ 0x00007fbc6213eac3 31. ? @ 0x00007fbc621d0850 (version 25.3.6.10636.altinitytest (altinity build)) 2025.07.28 11:57:34.492665 [ 3960 ] {} test_13.rmt2 (7f9b740d-015c-470e-8cc6-8ba33be0dc63): auto DB::StorageReplicatedMergeTree::processQueueEntry(ReplicatedMergeTreeQueue::SelectedEntryPtr)::(anonymous class)::operator()(LogEntryPtr &) const: Code: 86. DB::HTTPException: Received error from remote server http://146b4357c08d:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Ftest%2F01165%2Ftest_13%2Frmt%2Freplicas%2F1&part=20250728_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.6.10636.altinitytest (altinity build)) '. (RECEIVED_ERROR_FROM_REMOTE_IO_SERVER), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.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 const&, int&&, String const&, unsigned long&&, String const&) @ 0x000000000feda8d9 4. /build/src/IO/HTTPCommon.cpp:104: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x000000000feda6e2 5. /build/src/IO/HTTPCommon.cpp:93: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x000000000feda537 6. /build/src/IO/ReadWriteBufferFromHTTP.cpp:277: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x000000001184a4c4 7. /build/src/IO/ReadWriteBufferFromHTTP.cpp:285: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x000000001184a615 8. /build/src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x000000001184ae59 9. /build/src/IO/ReadWriteBufferFromHTTP.cpp:472: void std::__function::__policy_invoker::__call_impl[abi:se190107]>(std::__function::__policy_storage const*) @ 0x000000001184cedd 10. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001184858b 11. /build/src/IO/ReadWriteBufferFromHTTP.cpp:465: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x000000001184bf0b 12. /build/src/IO/ReadBuffer.h:60: DB::ReadBuffer::next() @ 0x000000000a148c7b 13. /build/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) @ 0x0000000011849fb2 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]>&)>&, 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&) @ 0x0000000011841980 15. /build/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) @ 0x000000001621208e 16. /build/src/Storages/StorageReplicatedMergeTree.cpp:5228: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl[abi:se190107] const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000015f9a5fe 17. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000015ed8bfd 18. /build/src/Storages/StorageReplicatedMergeTree.cpp:2514: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x0000000015ec9aab 19. /build/src/Storages/StorageReplicatedMergeTree.cpp:2349: DB::StorageReplicatedMergeTree::executeLogEntry(DB::ReplicatedMergeTreeLogEntry&) @ 0x0000000015eba91b 20. /build/src/Storages/StorageReplicatedMergeTree.cpp:3876: bool std::__function::__policy_invoker&)>::__call_impl[abi:se190107])::$_1, bool (std::shared_ptr&)>>(std::__function::__policy_storage const*, std::shared_ptr&) @ 0x0000000015f9837e 21. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000165d6fc3 22. /build/src/Storages/StorageReplicatedMergeTree.cpp:3872: DB::StorageReplicatedMergeTree::processQueueEntry(std::shared_ptr) @ 0x0000000015efc18a 23. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001624c1b2 24. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000162f9c70 25. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x00000000162fa55a 26. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc6653 27. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000000fccc4c3 28. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc3d92 29. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fcca080 30. ? @ 0x00007fbc6213eac3 31. ? @ 0x00007fbc621d0850 (version 25.3.6.10636.altinitytest (altinity build)) 2025.07.28 11:57:34.635486 [ 17611 ] {5d047b2e-f795-4926-ba9b-92ba60eec2cb} executeQuery: Code: 48. DB::Exception: Truncate is not supported by storage Merge. (NOT_IMPLEMENTED) (version 25.3.6.10636.altinitytest (altinity build)) (from [::1]:42814) (comment: 02987_logical_optimizer_pass_lowcardinality.sql) (in query: DROP DATABASE IF EXISTS test_u7o8s4uj SYNC ), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x000000000a06b56b 4. /build/src/Storages/IStorage.cpp:171: DB::IStorage::truncate(std::shared_ptr const&, std::shared_ptr const&, std::shared_ptr, DB::TableExclusiveLockHolder&) @ 0x0000000015d1ec7a 5. /build/src/Interpreters/InterpreterDropQuery.cpp:282: DB::InterpreterDropQuery::executeToTableImpl(std::shared_ptr const&, DB::ASTDropQuery&, std::shared_ptr&, StrongTypedef, DB::UUIDTag>&) @ 0x0000000014915304 6. /build/src/Interpreters/InterpreterDropQuery.cpp:461: DB::InterpreterDropQuery::executeToDatabaseImpl(DB::ASTDropQuery const&, std::shared_ptr&, std::vector, DB::UUIDTag>, std::allocator, DB::UUIDTag>>>&) @ 0x0000000014917707 7. /build/src/Interpreters/InterpreterDropQuery.cpp:363: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x0000000014913988 8. /build/src/Interpreters/InterpreterDropQuery.cpp:99: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000014913142 9. /build/src/Interpreters/InterpreterDropQuery.cpp:72: DB::InterpreterDropQuery::execute() @ 0x0000000014912b65 10. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88dc9 11. /build/src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x0000000014c8ca7b 12. /build/src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000001686da12 13. /build/src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x0000000016870807 14. /build/src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x0000000016907e99 15. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 16. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 17. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 18. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 19. ? @ 0x00007fbc6213eac3 20. ? @ 0x00007fbc621d0850 2025.07.28 11:57:34.637103 [ 17611 ] {5d047b2e-f795-4926-ba9b-92ba60eec2cb} DynamicQueryHandler: 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. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x000000000a06b56b 4. /build/src/Storages/IStorage.cpp:171: DB::IStorage::truncate(std::shared_ptr const&, std::shared_ptr const&, std::shared_ptr, DB::TableExclusiveLockHolder&) @ 0x0000000015d1ec7a 5. /build/src/Interpreters/InterpreterDropQuery.cpp:282: DB::InterpreterDropQuery::executeToTableImpl(std::shared_ptr const&, DB::ASTDropQuery&, std::shared_ptr&, StrongTypedef, DB::UUIDTag>&) @ 0x0000000014915304 6. /build/src/Interpreters/InterpreterDropQuery.cpp:461: DB::InterpreterDropQuery::executeToDatabaseImpl(DB::ASTDropQuery const&, std::shared_ptr&, std::vector, DB::UUIDTag>, std::allocator, DB::UUIDTag>>>&) @ 0x0000000014917707 7. /build/src/Interpreters/InterpreterDropQuery.cpp:363: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x0000000014913988 8. /build/src/Interpreters/InterpreterDropQuery.cpp:99: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000014913142 9. /build/src/Interpreters/InterpreterDropQuery.cpp:72: DB::InterpreterDropQuery::execute() @ 0x0000000014912b65 10. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88dc9 11. /build/src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x0000000014c8ca7b 12. /build/src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000001686da12 13. /build/src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x0000000016870807 14. /build/src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x0000000016907e99 15. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 16. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 17. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 18. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 19. ? @ 0x00007fbc6213eac3 20. ? @ 0x00007fbc621d0850 (version 25.3.6.10636.altinitytest (altinity build)) 2025.07.28 11:57:35.374266 [ 5825 ] {cae4bff3-3286-48ec-943e-54c7c5120186} executeQuery: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION) (version 25.3.6.10636.altinitytest (altinity build)) (from [::1]:46432) (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. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x000000000c25bc4b 4. /build/src/Access/SettingsConstraints.cpp:343: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000138596e3 5. /build/src/Access/SettingsConstraints.cpp:300: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000013858faf 6. /build/src/Access/SettingsConstraints.cpp:194: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges const&, DB::SettingSource) const @ 0x00000000138591b3 7. /build/src/Interpreters/Context.cpp:2722: DB::Context::checkSettingsConstraints(DB::SettingsChanges const&, DB::SettingSource) @ 0x0000000014436509 8. /build/src/Interpreters/InterpreterSetQuery.cpp:28: DB::InterpreterSetQuery::execute() @ 0x00000000149e240a 9. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88dc9 10. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 11. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 12. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 13. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 14. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 16. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 17. ? @ 0x00007fbc6213eac3 18. ? @ 0x00007fbc621d0850 2025.07.28 11:57:35.386625 [ 5825 ] {} 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. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x000000000c25bc4b 4. /build/src/Access/SettingsConstraints.cpp:343: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000138596e3 5. /build/src/Access/SettingsConstraints.cpp:300: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000013858faf 6. /build/src/Access/SettingsConstraints.cpp:194: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges const&, DB::SettingSource) const @ 0x00000000138591b3 7. /build/src/Interpreters/Context.cpp:2722: DB::Context::checkSettingsConstraints(DB::SettingsChanges const&, DB::SettingSource) @ 0x0000000014436509 8. /build/src/Interpreters/InterpreterSetQuery.cpp:28: DB::InterpreterSetQuery::execute() @ 0x00000000149e240a 9. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88dc9 10. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 11. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 12. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 13. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 14. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 16. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 17. ? @ 0x00007fbc6213eac3 18. ? @ 0x00007fbc621d0850 2025.07.28 11:57:35.580250 [ 3964 ] {} test_13.rmt2 (7f9b740d-015c-470e-8cc6-8ba33be0dc63): auto DB::StorageReplicatedMergeTree::processQueueEntry(ReplicatedMergeTreeQueue::SelectedEntryPtr)::(anonymous class)::operator()(LogEntryPtr &) const: Code: 86. DB::HTTPException: Received error from remote server http://146b4357c08d:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Ftest%2F01165%2Ftest_13%2Frmt%2Freplicas%2F1&part=20250728_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.6.10636.altinitytest (altinity build)) '. (RECEIVED_ERROR_FROM_REMOTE_IO_SERVER), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.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 const&, int&&, String const&, unsigned long&&, String const&) @ 0x000000000feda8d9 4. /build/src/IO/HTTPCommon.cpp:104: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x000000000feda6e2 5. /build/src/IO/HTTPCommon.cpp:93: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x000000000feda537 6. /build/src/IO/ReadWriteBufferFromHTTP.cpp:277: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x000000001184a4c4 7. /build/src/IO/ReadWriteBufferFromHTTP.cpp:285: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x000000001184a615 8. /build/src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x000000001184ae59 9. /build/src/IO/ReadWriteBufferFromHTTP.cpp:472: void std::__function::__policy_invoker::__call_impl[abi:se190107]>(std::__function::__policy_storage const*) @ 0x000000001184cedd 10. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001184858b 11. /build/src/IO/ReadWriteBufferFromHTTP.cpp:465: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x000000001184bf0b 12. /build/src/IO/ReadBuffer.h:60: DB::ReadBuffer::next() @ 0x000000000a148c7b 13. /build/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) @ 0x0000000011849fb2 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]>&)>&, 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&) @ 0x0000000011841980 15. /build/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) @ 0x000000001621208e 16. /build/src/Storages/StorageReplicatedMergeTree.cpp:5228: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl[abi:se190107] const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000015f9a5fe 17. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000015ed8bfd 18. /build/src/Storages/StorageReplicatedMergeTree.cpp:2514: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x0000000015ec9aab 19. /build/src/Storages/StorageReplicatedMergeTree.cpp:2349: DB::StorageReplicatedMergeTree::executeLogEntry(DB::ReplicatedMergeTreeLogEntry&) @ 0x0000000015eba91b 20. /build/src/Storages/StorageReplicatedMergeTree.cpp:3876: bool std::__function::__policy_invoker&)>::__call_impl[abi:se190107])::$_1, bool (std::shared_ptr&)>>(std::__function::__policy_storage const*, std::shared_ptr&) @ 0x0000000015f9837e 21. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000165d6fc3 22. /build/src/Storages/StorageReplicatedMergeTree.cpp:3872: DB::StorageReplicatedMergeTree::processQueueEntry(std::shared_ptr) @ 0x0000000015efc18a 23. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001624c1b2 24. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000162f9c70 25. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x00000000162fa55a 26. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc6653 27. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000000fccc4c3 28. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc3d92 29. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fcca080 30. ? @ 0x00007fbc6213eac3 31. ? @ 0x00007fbc621d0850 (version 25.3.6.10636.altinitytest (altinity build)) 2025.07.28 11:57:35.937983 [ 3961 ] {} test_13.rmt2 (7f9b740d-015c-470e-8cc6-8ba33be0dc63): auto DB::StorageReplicatedMergeTree::processQueueEntry(ReplicatedMergeTreeQueue::SelectedEntryPtr)::(anonymous class)::operator()(LogEntryPtr &) const: Code: 86. DB::HTTPException: Received error from remote server http://146b4357c08d:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Ftest%2F01165%2Ftest_13%2Frmt%2Freplicas%2F1&part=20250728_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.6.10636.altinitytest (altinity build)) '. (RECEIVED_ERROR_FROM_REMOTE_IO_SERVER), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.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 const&, int&&, String const&, unsigned long&&, String const&) @ 0x000000000feda8d9 4. /build/src/IO/HTTPCommon.cpp:104: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x000000000feda6e2 5. /build/src/IO/HTTPCommon.cpp:93: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x000000000feda537 6. /build/src/IO/ReadWriteBufferFromHTTP.cpp:277: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x000000001184a4c4 7. /build/src/IO/ReadWriteBufferFromHTTP.cpp:285: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x000000001184a615 8. /build/src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x000000001184ae59 9. /build/src/IO/ReadWriteBufferFromHTTP.cpp:472: void std::__function::__policy_invoker::__call_impl[abi:se190107]>(std::__function::__policy_storage const*) @ 0x000000001184cedd 10. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001184858b 11. /build/src/IO/ReadWriteBufferFromHTTP.cpp:465: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x000000001184bf0b 12. /build/src/IO/ReadBuffer.h:60: DB::ReadBuffer::next() @ 0x000000000a148c7b 13. /build/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) @ 0x0000000011849fb2 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]>&)>&, 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&) @ 0x0000000011841980 15. /build/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) @ 0x000000001621208e 16. /build/src/Storages/StorageReplicatedMergeTree.cpp:5228: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl[abi:se190107] const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000015f9a5fe 17. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000015ed8bfd 18. /build/src/Storages/StorageReplicatedMergeTree.cpp:2514: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x0000000015ec9aab 19. /build/src/Storages/StorageReplicatedMergeTree.cpp:2349: DB::StorageReplicatedMergeTree::executeLogEntry(DB::ReplicatedMergeTreeLogEntry&) @ 0x0000000015eba91b 20. /build/src/Storages/StorageReplicatedMergeTree.cpp:3876: bool std::__function::__policy_invoker&)>::__call_impl[abi:se190107])::$_1, bool (std::shared_ptr&)>>(std::__function::__policy_storage const*, std::shared_ptr&) @ 0x0000000015f9837e 21. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000165d6fc3 22. /build/src/Storages/StorageReplicatedMergeTree.cpp:3872: DB::StorageReplicatedMergeTree::processQueueEntry(std::shared_ptr) @ 0x0000000015efc18a 23. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001624c1b2 24. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000162f9c70 25. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x00000000162fa55a 26. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc6653 27. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000000fccc4c3 28. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc3d92 29. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fcca080 30. ? @ 0x00007fbc6213eac3 31. ? @ 0x00007fbc621d0850 (version 25.3.6.10636.altinitytest (altinity build)) 2025.07.28 11:57:36.604917 [ 3963 ] {} test_13.rmt2 (7f9b740d-015c-470e-8cc6-8ba33be0dc63): auto DB::StorageReplicatedMergeTree::processQueueEntry(ReplicatedMergeTreeQueue::SelectedEntryPtr)::(anonymous class)::operator()(LogEntryPtr &) const: Code: 86. DB::HTTPException: Received error from remote server http://146b4357c08d:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Ftest%2F01165%2Ftest_13%2Frmt%2Freplicas%2F1&part=20250728_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.6.10636.altinitytest (altinity build)) '. (RECEIVED_ERROR_FROM_REMOTE_IO_SERVER), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.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 const&, int&&, String const&, unsigned long&&, String const&) @ 0x000000000feda8d9 4. /build/src/IO/HTTPCommon.cpp:104: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x000000000feda6e2 5. /build/src/IO/HTTPCommon.cpp:93: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x000000000feda537 6. /build/src/IO/ReadWriteBufferFromHTTP.cpp:277: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x000000001184a4c4 7. /build/src/IO/ReadWriteBufferFromHTTP.cpp:285: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x000000001184a615 8. /build/src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x000000001184ae59 9. /build/src/IO/ReadWriteBufferFromHTTP.cpp:472: void std::__function::__policy_invoker::__call_impl[abi:se190107]>(std::__function::__policy_storage const*) @ 0x000000001184cedd 10. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001184858b 11. /build/src/IO/ReadWriteBufferFromHTTP.cpp:465: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x000000001184bf0b 12. /build/src/IO/ReadBuffer.h:60: DB::ReadBuffer::next() @ 0x000000000a148c7b 13. /build/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) @ 0x0000000011849fb2 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]>&)>&, 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&) @ 0x0000000011841980 15. /build/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) @ 0x000000001621208e 16. /build/src/Storages/StorageReplicatedMergeTree.cpp:5228: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl[abi:se190107] const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000015f9a5fe 17. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000015ed8bfd 18. /build/src/Storages/StorageReplicatedMergeTree.cpp:2514: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x0000000015ec9aab 19. /build/src/Storages/StorageReplicatedMergeTree.cpp:2349: DB::StorageReplicatedMergeTree::executeLogEntry(DB::ReplicatedMergeTreeLogEntry&) @ 0x0000000015eba91b 20. /build/src/Storages/StorageReplicatedMergeTree.cpp:3876: bool std::__function::__policy_invoker&)>::__call_impl[abi:se190107])::$_1, bool (std::shared_ptr&)>>(std::__function::__policy_storage const*, std::shared_ptr&) @ 0x0000000015f9837e 21. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000165d6fc3 22. /build/src/Storages/StorageReplicatedMergeTree.cpp:3872: DB::StorageReplicatedMergeTree::processQueueEntry(std::shared_ptr) @ 0x0000000015efc18a 23. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001624c1b2 24. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000162f9c70 25. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x00000000162fa55a 26. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc6653 27. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000000fccc4c3 28. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc3d92 29. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fcca080 30. ? @ 0x00007fbc6213eac3 31. ? @ 0x00007fbc621d0850 (version 25.3.6.10636.altinitytest (altinity build)) 2025.07.28 11:57:36.776255 [ 3967 ] {} test_13.rmt2 (7f9b740d-015c-470e-8cc6-8ba33be0dc63): auto DB::StorageReplicatedMergeTree::processQueueEntry(ReplicatedMergeTreeQueue::SelectedEntryPtr)::(anonymous class)::operator()(LogEntryPtr &) const: Code: 86. DB::HTTPException: Received error from remote server http://146b4357c08d:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Ftest%2F01165%2Ftest_13%2Frmt%2Freplicas%2F1&part=20250728_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.6.10636.altinitytest (altinity build)) '. (RECEIVED_ERROR_FROM_REMOTE_IO_SERVER), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.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 const&, int&&, String const&, unsigned long&&, String const&) @ 0x000000000feda8d9 4. /build/src/IO/HTTPCommon.cpp:104: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x000000000feda6e2 5. /build/src/IO/HTTPCommon.cpp:93: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x000000000feda537 6. /build/src/IO/ReadWriteBufferFromHTTP.cpp:277: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x000000001184a4c4 7. /build/src/IO/ReadWriteBufferFromHTTP.cpp:285: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x000000001184a615 8. /build/src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x000000001184ae59 9. /build/src/IO/ReadWriteBufferFromHTTP.cpp:472: void std::__function::__policy_invoker::__call_impl[abi:se190107]>(std::__function::__policy_storage const*) @ 0x000000001184cedd 10. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001184858b 11. /build/src/IO/ReadWriteBufferFromHTTP.cpp:465: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x000000001184bf0b 12. /build/src/IO/ReadBuffer.h:60: DB::ReadBuffer::next() @ 0x000000000a148c7b 13. /build/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) @ 0x0000000011849fb2 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]>&)>&, 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&) @ 0x0000000011841980 15. /build/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) @ 0x000000001621208e 16. /build/src/Storages/StorageReplicatedMergeTree.cpp:5228: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl[abi:se190107] const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000015f9a5fe 17. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000015ed8bfd 18. /build/src/Storages/StorageReplicatedMergeTree.cpp:2514: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x0000000015ec9aab 19. /build/src/Storages/StorageReplicatedMergeTree.cpp:2349: DB::StorageReplicatedMergeTree::executeLogEntry(DB::ReplicatedMergeTreeLogEntry&) @ 0x0000000015eba91b 20. /build/src/Storages/StorageReplicatedMergeTree.cpp:3876: bool std::__function::__policy_invoker&)>::__call_impl[abi:se190107])::$_1, bool (std::shared_ptr&)>>(std::__function::__policy_storage const*, std::shared_ptr&) @ 0x0000000015f9837e 21. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000165d6fc3 22. /build/src/Storages/StorageReplicatedMergeTree.cpp:3872: DB::StorageReplicatedMergeTree::processQueueEntry(std::shared_ptr) @ 0x0000000015efc18a 23. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001624c1b2 24. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000162f9c70 25. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x00000000162fa55a 26. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc6653 27. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000000fccc4c3 28. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc3d92 29. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fcca080 30. ? @ 0x00007fbc6213eac3 31. ? @ 0x00007fbc621d0850 (version 25.3.6.10636.altinitytest (altinity build)) 2025.07.28 11:57:37.313633 [ 3972 ] {} test_13.rmt2 (7f9b740d-015c-470e-8cc6-8ba33be0dc63): auto DB::StorageReplicatedMergeTree::processQueueEntry(ReplicatedMergeTreeQueue::SelectedEntryPtr)::(anonymous class)::operator()(LogEntryPtr &) const: Code: 86. DB::HTTPException: Received error from remote server http://146b4357c08d:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Ftest%2F01165%2Ftest_13%2Frmt%2Freplicas%2F1&part=20250728_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.6.10636.altinitytest (altinity build)) '. (RECEIVED_ERROR_FROM_REMOTE_IO_SERVER), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.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 const&, int&&, String const&, unsigned long&&, String const&) @ 0x000000000feda8d9 4. /build/src/IO/HTTPCommon.cpp:104: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x000000000feda6e2 5. /build/src/IO/HTTPCommon.cpp:93: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x000000000feda537 6. /build/src/IO/ReadWriteBufferFromHTTP.cpp:277: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x000000001184a4c4 7. /build/src/IO/ReadWriteBufferFromHTTP.cpp:285: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x000000001184a615 8. /build/src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x000000001184ae59 9. /build/src/IO/ReadWriteBufferFromHTTP.cpp:472: void std::__function::__policy_invoker::__call_impl[abi:se190107]>(std::__function::__policy_storage const*) @ 0x000000001184cedd 10. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001184858b 11. /build/src/IO/ReadWriteBufferFromHTTP.cpp:465: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x000000001184bf0b 12. /build/src/IO/ReadBuffer.h:60: DB::ReadBuffer::next() @ 0x000000000a148c7b 13. /build/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) @ 0x0000000011849fb2 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]>&)>&, 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&) @ 0x0000000011841980 15. /build/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) @ 0x000000001621208e 16. /build/src/Storages/StorageReplicatedMergeTree.cpp:5228: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl[abi:se190107] const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000015f9a5fe 17. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000015ed8bfd 18. /build/src/Storages/StorageReplicatedMergeTree.cpp:2514: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x0000000015ec9aab 19. /build/src/Storages/StorageReplicatedMergeTree.cpp:2349: DB::StorageReplicatedMergeTree::executeLogEntry(DB::ReplicatedMergeTreeLogEntry&) @ 0x0000000015eba91b 20. /build/src/Storages/StorageReplicatedMergeTree.cpp:3876: bool std::__function::__policy_invoker&)>::__call_impl[abi:se190107])::$_1, bool (std::shared_ptr&)>>(std::__function::__policy_storage const*, std::shared_ptr&) @ 0x0000000015f9837e 21. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000165d6fc3 22. /build/src/Storages/StorageReplicatedMergeTree.cpp:3872: DB::StorageReplicatedMergeTree::processQueueEntry(std::shared_ptr) @ 0x0000000015efc18a 23. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001624c1b2 24. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000162f9c70 25. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x00000000162fa55a 26. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc6653 27. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000000fccc4c3 28. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc3d92 29. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fcca080 30. ? @ 0x00007fbc6213eac3 31. ? @ 0x00007fbc621d0850 (version 25.3.6.10636.altinitytest (altinity build)) 2025.07.28 11:57:37.748411 [ 17191 ] {a283d0bb-4d3b-4fd7-8976-82ef91fc3b36} executeQuery: Code: 452. DB::Exception: Setting allow_experimental_object_type should not be changed. (SETTING_CONSTRAINT_VIOLATION) (version 25.3.6.10636.altinitytest (altinity build)) (from [::1]:46550) (comment: 01825_type_json_10.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. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x000000000c25bc4b 4. /build/src/Access/SettingsConstraints.cpp:343: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000138596e3 5. /build/src/Access/SettingsConstraints.cpp:300: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000013858faf 6. /build/src/Access/SettingsConstraints.cpp:194: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges const&, DB::SettingSource) const @ 0x00000000138591b3 7. /build/src/Interpreters/Context.cpp:2722: DB::Context::checkSettingsConstraints(DB::SettingsChanges const&, DB::SettingSource) @ 0x0000000014436509 8. /build/src/Interpreters/InterpreterSetQuery.cpp:28: DB::InterpreterSetQuery::execute() @ 0x00000000149e240a 9. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88dc9 10. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 11. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 12. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 13. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 14. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 16. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 17. ? @ 0x00007fbc6213eac3 18. ? @ 0x00007fbc621d0850 2025.07.28 11:57:37.759054 [ 17191 ] {} 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. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x000000000c25bc4b 4. /build/src/Access/SettingsConstraints.cpp:343: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000138596e3 5. /build/src/Access/SettingsConstraints.cpp:300: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000013858faf 6. /build/src/Access/SettingsConstraints.cpp:194: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges const&, DB::SettingSource) const @ 0x00000000138591b3 7. /build/src/Interpreters/Context.cpp:2722: DB::Context::checkSettingsConstraints(DB::SettingsChanges const&, DB::SettingSource) @ 0x0000000014436509 8. /build/src/Interpreters/InterpreterSetQuery.cpp:28: DB::InterpreterSetQuery::execute() @ 0x00000000149e240a 9. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88dc9 10. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 11. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 12. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 13. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 14. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 16. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 17. ? @ 0x00007fbc6213eac3 18. ? @ 0x00007fbc621d0850 2025.07.28 11:57:37.836340 [ 3968 ] {} test_13.rmt2 (7f9b740d-015c-470e-8cc6-8ba33be0dc63): auto DB::StorageReplicatedMergeTree::processQueueEntry(ReplicatedMergeTreeQueue::SelectedEntryPtr)::(anonymous class)::operator()(LogEntryPtr &) const: Code: 86. DB::HTTPException: Received error from remote server http://146b4357c08d:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Ftest%2F01165%2Ftest_13%2Frmt%2Freplicas%2F1&part=20250728_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.6.10636.altinitytest (altinity build)) '. (RECEIVED_ERROR_FROM_REMOTE_IO_SERVER), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.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 const&, int&&, String const&, unsigned long&&, String const&) @ 0x000000000feda8d9 4. /build/src/IO/HTTPCommon.cpp:104: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x000000000feda6e2 5. /build/src/IO/HTTPCommon.cpp:93: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x000000000feda537 6. /build/src/IO/ReadWriteBufferFromHTTP.cpp:277: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x000000001184a4c4 7. /build/src/IO/ReadWriteBufferFromHTTP.cpp:285: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x000000001184a615 8. /build/src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x000000001184ae59 9. /build/src/IO/ReadWriteBufferFromHTTP.cpp:472: void std::__function::__policy_invoker::__call_impl[abi:se190107]>(std::__function::__policy_storage const*) @ 0x000000001184cedd 10. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001184858b 11. /build/src/IO/ReadWriteBufferFromHTTP.cpp:465: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x000000001184bf0b 12. /build/src/IO/ReadBuffer.h:60: DB::ReadBuffer::next() @ 0x000000000a148c7b 13. /build/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) @ 0x0000000011849fb2 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]>&)>&, 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&) @ 0x0000000011841980 15. /build/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) @ 0x000000001621208e 16. /build/src/Storages/StorageReplicatedMergeTree.cpp:5228: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl[abi:se190107] const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000015f9a5fe 17. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000015ed8bfd 18. /build/src/Storages/StorageReplicatedMergeTree.cpp:2514: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x0000000015ec9aab 19. /build/src/Storages/StorageReplicatedMergeTree.cpp:2349: DB::StorageReplicatedMergeTree::executeLogEntry(DB::ReplicatedMergeTreeLogEntry&) @ 0x0000000015eba91b 20. /build/src/Storages/StorageReplicatedMergeTree.cpp:3876: bool std::__function::__policy_invoker&)>::__call_impl[abi:se190107])::$_1, bool (std::shared_ptr&)>>(std::__function::__policy_storage const*, std::shared_ptr&) @ 0x0000000015f9837e 21. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000165d6fc3 22. /build/src/Storages/StorageReplicatedMergeTree.cpp:3872: DB::StorageReplicatedMergeTree::processQueueEntry(std::shared_ptr) @ 0x0000000015efc18a 23. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001624c1b2 24. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000162f9c70 25. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x00000000162fa55a 26. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc6653 27. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000000fccc4c3 28. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc3d92 29. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fcca080 30. ? @ 0x00007fbc6213eac3 31. ? @ 0x00007fbc621d0850 (version 25.3.6.10636.altinitytest (altinity build)) 2025.07.28 11:57:38.820347 [ 3962 ] {} test_13.rmt2 (7f9b740d-015c-470e-8cc6-8ba33be0dc63): auto DB::StorageReplicatedMergeTree::processQueueEntry(ReplicatedMergeTreeQueue::SelectedEntryPtr)::(anonymous class)::operator()(LogEntryPtr &) const: Code: 86. DB::HTTPException: Received error from remote server http://146b4357c08d:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Ftest%2F01165%2Ftest_13%2Frmt%2Freplicas%2F1&part=20250728_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.6.10636.altinitytest (altinity build)) '. (RECEIVED_ERROR_FROM_REMOTE_IO_SERVER), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.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 const&, int&&, String const&, unsigned long&&, String const&) @ 0x000000000feda8d9 4. /build/src/IO/HTTPCommon.cpp:104: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x000000000feda6e2 5. /build/src/IO/HTTPCommon.cpp:93: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x000000000feda537 6. /build/src/IO/ReadWriteBufferFromHTTP.cpp:277: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x000000001184a4c4 7. /build/src/IO/ReadWriteBufferFromHTTP.cpp:285: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x000000001184a615 8. /build/src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x000000001184ae59 9. /build/src/IO/ReadWriteBufferFromHTTP.cpp:472: void std::__function::__policy_invoker::__call_impl[abi:se190107]>(std::__function::__policy_storage const*) @ 0x000000001184cedd 10. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001184858b 11. /build/src/IO/ReadWriteBufferFromHTTP.cpp:465: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x000000001184bf0b 12. /build/src/IO/ReadBuffer.h:60: DB::ReadBuffer::next() @ 0x000000000a148c7b 13. /build/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) @ 0x0000000011849fb2 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]>&)>&, 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&) @ 0x0000000011841980 15. /build/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) @ 0x000000001621208e 16. /build/src/Storages/StorageReplicatedMergeTree.cpp:5228: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl[abi:se190107] const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000015f9a5fe 17. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000015ed8bfd 18. /build/src/Storages/StorageReplicatedMergeTree.cpp:2514: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x0000000015ec9aab 19. /build/src/Storages/StorageReplicatedMergeTree.cpp:2349: DB::StorageReplicatedMergeTree::executeLogEntry(DB::ReplicatedMergeTreeLogEntry&) @ 0x0000000015eba91b 20. /build/src/Storages/StorageReplicatedMergeTree.cpp:3876: bool std::__function::__policy_invoker&)>::__call_impl[abi:se190107])::$_1, bool (std::shared_ptr&)>>(std::__function::__policy_storage const*, std::shared_ptr&) @ 0x0000000015f9837e 21. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000165d6fc3 22. /build/src/Storages/StorageReplicatedMergeTree.cpp:3872: DB::StorageReplicatedMergeTree::processQueueEntry(std::shared_ptr) @ 0x0000000015efc18a 23. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001624c1b2 24. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000162f9c70 25. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x00000000162fa55a 26. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc6653 27. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000000fccc4c3 28. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc3d92 29. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fcca080 30. ? @ 0x00007fbc6213eac3 31. ? @ 0x00007fbc621d0850 (version 25.3.6.10636.altinitytest (altinity build)) 2025.07.28 11:57:38.969306 [ 17371 ] {f5a5db51-1f6a-422f-9739-e688084b1eb9} executeQuery: Code: 42. DB::Exception: Number of arguments for function byteSwap doesn't match: passed 0, should be 1: In scope SELECT byteSwap(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.6.10636.altinitytest (altinity build)) (from [::1]:46460) (comment: 02887_byteswap.sql) (query 34, line 46) (in query: -- Number of arguments should equal 1 SELECT byteSwap();), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, unsigned long&, unsigned long&) @ 0x00000000120bbe2b 4. /build/src/Functions/IFunction.cpp:539: DB::IFunctionOverloadResolver::checkNumberOfArguments(unsigned long) const @ 0x0000000012d9640d 5. /build/src/Functions/IFunction.cpp:593: DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x0000000012d96bf3 6. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3544: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000014033cc9 7. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3838: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000014019a9e 8. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3980: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000014018e31 9. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:4304: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000014042fa7 10. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5605: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000014013749 11. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000140127f9 12. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000014011fce 13. /build/src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000001406ce8a 14. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000014973b42 15. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000001497268d 16. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000014974d24 17. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001492924b 18. /build/src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88641 19. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 20. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 21. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 22. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 23. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 24. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 25. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 26. ? @ 0x00007fbc6213eac3 27. ? @ 0x00007fbc621d0850 2025.07.28 11:57:38.977291 [ 17371 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function byteSwap doesn't match: passed 0, should be 1: In scope SELECT byteSwap(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, unsigned long&, unsigned long&) @ 0x00000000120bbe2b 4. /build/src/Functions/IFunction.cpp:539: DB::IFunctionOverloadResolver::checkNumberOfArguments(unsigned long) const @ 0x0000000012d9640d 5. /build/src/Functions/IFunction.cpp:593: DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x0000000012d96bf3 6. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3544: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000014033cc9 7. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3838: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000014019a9e 8. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3980: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000014018e31 9. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:4304: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000014042fa7 10. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5605: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000014013749 11. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000140127f9 12. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000014011fce 13. /build/src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000001406ce8a 14. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000014973b42 15. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000001497268d 16. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000014974d24 17. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001492924b 18. /build/src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88641 19. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 20. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 21. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 22. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 23. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 24. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 25. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 26. ? @ 0x00007fbc6213eac3 27. ? @ 0x00007fbc621d0850 2025.07.28 11:57:39.092450 [ 17371 ] {67132a18-9dcd-4a10-8782-a6013c306ff6} executeQuery: Code: 42. DB::Exception: Number of arguments for function byteSwap doesn't match: passed 2, should be 1: In scope SELECT byteSwap(128, 129). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.6.10636.altinitytest (altinity build)) (from [::1]:46460) (comment: 02887_byteswap.sql) (query 35, line 48) (in query: SELECT byteSwap(128, 129);), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, unsigned long&, unsigned long&) @ 0x00000000120bbe2b 4. /build/src/Functions/IFunction.cpp:539: DB::IFunctionOverloadResolver::checkNumberOfArguments(unsigned long) const @ 0x0000000012d9640d 5. /build/src/Functions/IFunction.cpp:593: DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x0000000012d96bf3 6. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3544: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000014033cc9 7. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3838: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000014019a9e 8. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3980: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000014018e31 9. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:4304: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000014042fa7 10. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5605: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000014013749 11. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000140127f9 12. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000014011fce 13. /build/src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000001406ce8a 14. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000014973b42 15. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000001497268d 16. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000014974d24 17. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001492924b 18. /build/src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88641 19. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 20. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 21. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 22. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 23. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 24. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 25. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 26. ? @ 0x00007fbc6213eac3 27. ? @ 0x00007fbc621d0850 2025.07.28 11:57:39.106891 [ 17371 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function byteSwap doesn't match: passed 2, should be 1: In scope SELECT byteSwap(128, 129). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, unsigned long&, unsigned long&) @ 0x00000000120bbe2b 4. /build/src/Functions/IFunction.cpp:539: DB::IFunctionOverloadResolver::checkNumberOfArguments(unsigned long) const @ 0x0000000012d9640d 5. /build/src/Functions/IFunction.cpp:593: DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x0000000012d96bf3 6. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3544: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000014033cc9 7. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3838: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000014019a9e 8. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3980: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000014018e31 9. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:4304: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000014042fa7 10. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5605: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000014013749 11. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000140127f9 12. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000014011fce 13. /build/src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000001406ce8a 14. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000014973b42 15. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000001497268d 16. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000014974d24 17. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001492924b 18. /build/src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88641 19. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 20. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 21. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 22. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 23. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 24. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 25. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 26. ? @ 0x00007fbc6213eac3 27. ? @ 0x00007fbc621d0850 2025.07.28 11:57:39.219887 [ 17371 ] {25f06a56-6d06-4461-a736-1d662e19c9ce} executeQuery: Code: 43. DB::Exception: Illegal type String of argument of function byteSwap: In scope SELECT byteSwap('abc'). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.6.10636.altinitytest (altinity build)) (from [::1]:46460) (comment: 02887_byteswap.sql) (query 36, line 50) (in query: -- Input should be integral SELECT byteSwap('abc');), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000a06a8eb 4. /build/src/Functions/FunctionUnaryArithmetic.h:332: DB::FunctionUnaryArithmetic::getReturnTypeImpl(std::vector, std::allocator>> const&) const @ 0x000000000b2098fd 5. /build/src/Functions/IFunction.h:520: DB::IFunction::getReturnTypeImpl(std::vector> const&) const @ 0x000000000a06a2de 6. /build/src/Functions/IFunction.cpp:645: DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x0000000012d96b0c 7. /build/src/Functions/IFunction.cpp:577: DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x0000000012d9669c 8. /build/src/Functions/IFunction.cpp:606: DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x0000000012d96edc 9. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3544: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000014033cc9 10. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3838: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000014019a9e 11. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3980: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000014018e31 12. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:4304: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000014042fa7 13. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5605: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000014013749 14. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000140127f9 15. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000014011fce 16. /build/src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000001406ce8a 17. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000014973b42 18. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000001497268d 19. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000014974d24 20. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001492924b 21. /build/src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88641 22. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 23. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 24. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 25. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 26. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 27. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 28. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 29. ? @ 0x00007fbc6213eac3 30. ? @ 0x00007fbc621d0850 2025.07.28 11:57:39.223243 [ 17371 ] {} TCPHandler: Code: 43. DB::Exception: Illegal type String of argument of function byteSwap: In scope SELECT byteSwap('abc'). (ILLEGAL_TYPE_OF_ARGUMENT), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000a06a8eb 4. /build/src/Functions/FunctionUnaryArithmetic.h:332: DB::FunctionUnaryArithmetic::getReturnTypeImpl(std::vector, std::allocator>> const&) const @ 0x000000000b2098fd 5. /build/src/Functions/IFunction.h:520: DB::IFunction::getReturnTypeImpl(std::vector> const&) const @ 0x000000000a06a2de 6. /build/src/Functions/IFunction.cpp:645: DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x0000000012d96b0c 7. /build/src/Functions/IFunction.cpp:577: DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x0000000012d9669c 8. /build/src/Functions/IFunction.cpp:606: DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x0000000012d96edc 9. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3544: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000014033cc9 10. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3838: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000014019a9e 11. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3980: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000014018e31 12. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:4304: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000014042fa7 13. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5605: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000014013749 14. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000140127f9 15. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000014011fce 16. /build/src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000001406ce8a 17. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000014973b42 18. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000001497268d 19. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000014974d24 20. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001492924b 21. /build/src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88641 22. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 23. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 24. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 25. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 26. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 27. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 28. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 29. ? @ 0x00007fbc6213eac3 30. ? @ 0x00007fbc621d0850 2025.07.28 11:57:39.246346 [ 17371 ] {e1171fca-3861-4892-ba2a-030378297bef} executeQuery: Code: 43. DB::Exception: Illegal type FixedString(3) of argument of function byteSwap: In scope SELECT byteSwap(toFixedString('abc', 3)). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.6.10636.altinitytest (altinity build)) (from [::1]:46460) (comment: 02887_byteswap.sql) (query 37, line 52) (in query: SELECT byteSwap(toFixedString('abc', 3));), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000a06a8eb 4. /build/src/Functions/FunctionUnaryArithmetic.h:332: DB::FunctionUnaryArithmetic::getReturnTypeImpl(std::vector, std::allocator>> const&) const @ 0x000000000b2098fd 5. /build/src/Functions/IFunction.h:520: DB::IFunction::getReturnTypeImpl(std::vector> const&) const @ 0x000000000a06a2de 6. /build/src/Functions/IFunction.cpp:645: DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x0000000012d96b0c 7. /build/src/Functions/IFunction.cpp:577: DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x0000000012d9669c 8. /build/src/Functions/IFunction.cpp:606: DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x0000000012d96edc 9. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3544: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000014033cc9 10. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3838: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000014019a9e 11. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3980: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000014018e31 12. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:4304: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000014042fa7 13. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5605: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000014013749 14. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000140127f9 15. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000014011fce 16. /build/src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000001406ce8a 17. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000014973b42 18. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000001497268d 19. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000014974d24 20. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001492924b 21. /build/src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88641 22. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 23. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 24. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 25. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 26. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 27. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 28. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 29. ? @ 0x00007fbc6213eac3 30. ? @ 0x00007fbc621d0850 2025.07.28 11:57:39.248998 [ 17371 ] {} TCPHandler: Code: 43. DB::Exception: Illegal type FixedString(3) of argument of function byteSwap: In scope SELECT byteSwap(toFixedString('abc', 3)). (ILLEGAL_TYPE_OF_ARGUMENT), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000a06a8eb 4. /build/src/Functions/FunctionUnaryArithmetic.h:332: DB::FunctionUnaryArithmetic::getReturnTypeImpl(std::vector, std::allocator>> const&) const @ 0x000000000b2098fd 5. /build/src/Functions/IFunction.h:520: DB::IFunction::getReturnTypeImpl(std::vector> const&) const @ 0x000000000a06a2de 6. /build/src/Functions/IFunction.cpp:645: DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x0000000012d96b0c 7. /build/src/Functions/IFunction.cpp:577: DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x0000000012d9669c 8. /build/src/Functions/IFunction.cpp:606: DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x0000000012d96edc 9. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3544: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000014033cc9 10. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3838: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000014019a9e 11. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3980: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000014018e31 12. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:4304: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000014042fa7 13. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5605: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000014013749 14. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000140127f9 15. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000014011fce 16. /build/src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000001406ce8a 17. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000014973b42 18. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000001497268d 19. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000014974d24 20. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001492924b 21. /build/src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88641 22. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 23. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 24. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 25. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 26. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 27. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 28. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 29. ? @ 0x00007fbc6213eac3 30. ? @ 0x00007fbc621d0850 2025.07.28 11:57:39.276216 [ 17371 ] {d0f33463-de1d-4073-b238-a0070fc2d2f0} executeQuery: Code: 43. DB::Exception: Illegal type Date of argument of function byteSwap: In scope SELECT byteSwap(toDate('2019-01-01')). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.6.10636.altinitytest (altinity build)) (from [::1]:46460) (comment: 02887_byteswap.sql) (query 38, line 53) (in query: SELECT byteSwap(toDate('2019-01-01'));), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000a06a8eb 4. /build/src/Functions/FunctionUnaryArithmetic.h:332: DB::FunctionUnaryArithmetic::getReturnTypeImpl(std::vector, std::allocator>> const&) const @ 0x000000000b2098fd 5. /build/src/Functions/IFunction.h:520: DB::IFunction::getReturnTypeImpl(std::vector> const&) const @ 0x000000000a06a2de 6. /build/src/Functions/IFunction.cpp:645: DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x0000000012d96b0c 7. /build/src/Functions/IFunction.cpp:577: DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x0000000012d9669c 8. /build/src/Functions/IFunction.cpp:606: DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x0000000012d96edc 9. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3544: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000014033cc9 10. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3838: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000014019a9e 11. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3980: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000014018e31 12. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:4304: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000014042fa7 13. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5605: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000014013749 14. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000140127f9 15. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000014011fce 16. /build/src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000001406ce8a 17. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000014973b42 18. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000001497268d 19. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000014974d24 20. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001492924b 21. /build/src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88641 22. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 23. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 24. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 25. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 26. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 27. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 28. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 29. ? @ 0x00007fbc6213eac3 30. ? @ 0x00007fbc621d0850 2025.07.28 11:57:39.289620 [ 17371 ] {} TCPHandler: Code: 43. DB::Exception: Illegal type Date of argument of function byteSwap: In scope SELECT byteSwap(toDate('2019-01-01')). (ILLEGAL_TYPE_OF_ARGUMENT), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000a06a8eb 4. /build/src/Functions/FunctionUnaryArithmetic.h:332: DB::FunctionUnaryArithmetic::getReturnTypeImpl(std::vector, std::allocator>> const&) const @ 0x000000000b2098fd 5. /build/src/Functions/IFunction.h:520: DB::IFunction::getReturnTypeImpl(std::vector> const&) const @ 0x000000000a06a2de 6. /build/src/Functions/IFunction.cpp:645: DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x0000000012d96b0c 7. /build/src/Functions/IFunction.cpp:577: DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x0000000012d9669c 8. /build/src/Functions/IFunction.cpp:606: DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x0000000012d96edc 9. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3544: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000014033cc9 10. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3838: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000014019a9e 11. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3980: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000014018e31 12. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:4304: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000014042fa7 13. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5605: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000014013749 14. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000140127f9 15. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000014011fce 16. /build/src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000001406ce8a 17. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000014973b42 18. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000001497268d 19. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000014974d24 20. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001492924b 21. /build/src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88641 22. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 23. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 24. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 25. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 26. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 27. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 28. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 29. ? @ 0x00007fbc6213eac3 30. ? @ 0x00007fbc621d0850 2025.07.28 11:57:39.335719 [ 17371 ] {bbeafea8-fbc0-43b2-9327-6f11e4bf5f44} executeQuery: Code: 43. DB::Exception: Illegal type Date32 of argument of function byteSwap: In scope SELECT byteSwap(toDate32('2019-01-01')). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.6.10636.altinitytest (altinity build)) (from [::1]:46460) (comment: 02887_byteswap.sql) (query 39, line 54) (in query: SELECT byteSwap(toDate32('2019-01-01'));), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000a06a8eb 4. /build/src/Functions/FunctionUnaryArithmetic.h:332: DB::FunctionUnaryArithmetic::getReturnTypeImpl(std::vector, std::allocator>> const&) const @ 0x000000000b2098fd 5. /build/src/Functions/IFunction.h:520: DB::IFunction::getReturnTypeImpl(std::vector> const&) const @ 0x000000000a06a2de 6. /build/src/Functions/IFunction.cpp:645: DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x0000000012d96b0c 7. /build/src/Functions/IFunction.cpp:577: DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x0000000012d9669c 8. /build/src/Functions/IFunction.cpp:606: DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x0000000012d96edc 9. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3544: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000014033cc9 10. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3838: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000014019a9e 11. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3980: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000014018e31 12. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:4304: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000014042fa7 13. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5605: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000014013749 14. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000140127f9 15. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000014011fce 16. /build/src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000001406ce8a 17. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000014973b42 18. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000001497268d 19. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000014974d24 20. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001492924b 21. /build/src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88641 22. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 23. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 24. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 25. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 26. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 27. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 28. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 29. ? @ 0x00007fbc6213eac3 30. ? @ 0x00007fbc621d0850 2025.07.28 11:57:39.339977 [ 17371 ] {} TCPHandler: Code: 43. DB::Exception: Illegal type Date32 of argument of function byteSwap: In scope SELECT byteSwap(toDate32('2019-01-01')). (ILLEGAL_TYPE_OF_ARGUMENT), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000a06a8eb 4. /build/src/Functions/FunctionUnaryArithmetic.h:332: DB::FunctionUnaryArithmetic::getReturnTypeImpl(std::vector, std::allocator>> const&) const @ 0x000000000b2098fd 5. /build/src/Functions/IFunction.h:520: DB::IFunction::getReturnTypeImpl(std::vector> const&) const @ 0x000000000a06a2de 6. /build/src/Functions/IFunction.cpp:645: DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x0000000012d96b0c 7. /build/src/Functions/IFunction.cpp:577: DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x0000000012d9669c 8. /build/src/Functions/IFunction.cpp:606: DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x0000000012d96edc 9. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3544: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000014033cc9 10. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3838: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000014019a9e 11. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3980: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000014018e31 12. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:4304: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000014042fa7 13. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5605: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000014013749 14. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000140127f9 15. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000014011fce 16. /build/src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000001406ce8a 17. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000014973b42 18. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000001497268d 19. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000014974d24 20. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001492924b 21. /build/src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88641 22. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 23. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 24. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 25. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 26. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 27. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 28. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 29. ? @ 0x00007fbc6213eac3 30. ? @ 0x00007fbc621d0850 2025.07.28 11:57:39.387254 [ 17371 ] {a7aff6d1-ef4d-4f7d-8d66-a4611aedb5bc} executeQuery: Code: 43. DB::Exception: Illegal type DateTime of argument of function byteSwap: In scope SELECT byteSwap(toDateTime32(1546300800)). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.6.10636.altinitytest (altinity build)) (from [::1]:46460) (comment: 02887_byteswap.sql) (query 40, line 55) (in query: SELECT byteSwap(toDateTime32(1546300800));), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000a06a8eb 4. /build/src/Functions/FunctionUnaryArithmetic.h:332: DB::FunctionUnaryArithmetic::getReturnTypeImpl(std::vector, std::allocator>> const&) const @ 0x000000000b2098fd 5. /build/src/Functions/IFunction.h:520: DB::IFunction::getReturnTypeImpl(std::vector> const&) const @ 0x000000000a06a2de 6. /build/src/Functions/IFunction.cpp:645: DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x0000000012d96b0c 7. /build/src/Functions/IFunction.cpp:577: DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x0000000012d9669c 8. /build/src/Functions/IFunction.cpp:606: DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x0000000012d96edc 9. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3544: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000014033cc9 10. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3838: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000014019a9e 11. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3980: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000014018e31 12. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:4304: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000014042fa7 13. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5605: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000014013749 14. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000140127f9 15. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000014011fce 16. /build/src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000001406ce8a 17. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000014973b42 18. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000001497268d 19. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000014974d24 20. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001492924b 21. /build/src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88641 22. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 23. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 24. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 25. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 26. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 27. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 28. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 29. ? @ 0x00007fbc6213eac3 30. ? @ 0x00007fbc621d0850 2025.07.28 11:57:39.394475 [ 17371 ] {} TCPHandler: Code: 43. DB::Exception: Illegal type DateTime of argument of function byteSwap: In scope SELECT byteSwap(toDateTime32(1546300800)). (ILLEGAL_TYPE_OF_ARGUMENT), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000a06a8eb 4. /build/src/Functions/FunctionUnaryArithmetic.h:332: DB::FunctionUnaryArithmetic::getReturnTypeImpl(std::vector, std::allocator>> const&) const @ 0x000000000b2098fd 5. /build/src/Functions/IFunction.h:520: DB::IFunction::getReturnTypeImpl(std::vector> const&) const @ 0x000000000a06a2de 6. /build/src/Functions/IFunction.cpp:645: DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x0000000012d96b0c 7. /build/src/Functions/IFunction.cpp:577: DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x0000000012d9669c 8. /build/src/Functions/IFunction.cpp:606: DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x0000000012d96edc 9. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3544: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000014033cc9 10. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3838: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000014019a9e 11. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3980: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000014018e31 12. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:4304: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000014042fa7 13. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5605: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000014013749 14. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000140127f9 15. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000014011fce 16. /build/src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000001406ce8a 17. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000014973b42 18. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000001497268d 19. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000014974d24 20. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001492924b 21. /build/src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88641 22. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 23. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 24. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 25. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 26. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 27. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 28. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 29. ? @ 0x00007fbc6213eac3 30. ? @ 0x00007fbc621d0850 2025.07.28 11:57:39.414829 [ 17371 ] {19be5f88-af86-4cc6-a545-7570dbd9f295} executeQuery: Code: 43. DB::Exception: Illegal type DateTime64(3) of argument of function byteSwap: In scope SELECT byteSwap(toDateTime64(1546300800, 3)). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.6.10636.altinitytest (altinity build)) (from [::1]:46460) (comment: 02887_byteswap.sql) (query 41, line 56) (in query: SELECT byteSwap(toDateTime64(1546300800, 3));), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000a06a8eb 4. /build/src/Functions/FunctionUnaryArithmetic.h:332: DB::FunctionUnaryArithmetic::getReturnTypeImpl(std::vector, std::allocator>> const&) const @ 0x000000000b2098fd 5. /build/src/Functions/IFunction.h:520: DB::IFunction::getReturnTypeImpl(std::vector> const&) const @ 0x000000000a06a2de 6. /build/src/Functions/IFunction.cpp:645: DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x0000000012d96b0c 7. /build/src/Functions/IFunction.cpp:577: DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x0000000012d9669c 8. /build/src/Functions/IFunction.cpp:606: DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x0000000012d96edc 9. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3544: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000014033cc9 10. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3838: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000014019a9e 11. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3980: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000014018e31 12. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:4304: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000014042fa7 13. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5605: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000014013749 14. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000140127f9 15. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000014011fce 16. /build/src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000001406ce8a 17. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000014973b42 18. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000001497268d 19. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000014974d24 20. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001492924b 21. /build/src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88641 22. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 23. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 24. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 25. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 26. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 27. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 28. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 29. ? @ 0x00007fbc6213eac3 30. ? @ 0x00007fbc621d0850 2025.07.28 11:57:39.417225 [ 17371 ] {} TCPHandler: Code: 43. DB::Exception: Illegal type DateTime64(3) of argument of function byteSwap: In scope SELECT byteSwap(toDateTime64(1546300800, 3)). (ILLEGAL_TYPE_OF_ARGUMENT), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000a06a8eb 4. /build/src/Functions/FunctionUnaryArithmetic.h:332: DB::FunctionUnaryArithmetic::getReturnTypeImpl(std::vector, std::allocator>> const&) const @ 0x000000000b2098fd 5. /build/src/Functions/IFunction.h:520: DB::IFunction::getReturnTypeImpl(std::vector> const&) const @ 0x000000000a06a2de 6. /build/src/Functions/IFunction.cpp:645: DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x0000000012d96b0c 7. /build/src/Functions/IFunction.cpp:577: DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x0000000012d9669c 8. /build/src/Functions/IFunction.cpp:606: DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x0000000012d96edc 9. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3544: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000014033cc9 10. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3838: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000014019a9e 11. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3980: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000014018e31 12. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:4304: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000014042fa7 13. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5605: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000014013749 14. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000140127f9 15. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000014011fce 16. /build/src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000001406ce8a 17. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000014973b42 18. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000001497268d 19. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000014974d24 20. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001492924b 21. /build/src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88641 22. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 23. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 24. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 25. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 26. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 27. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 28. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 29. ? @ 0x00007fbc6213eac3 30. ? @ 0x00007fbc621d0850 2025.07.28 11:57:39.442955 [ 17371 ] {c4333d6c-5409-4681-9d79-e618a2c39d6e} executeQuery: Code: 43. DB::Exception: Illegal type UUID of argument of function byteSwap: In scope SELECT byteSwap(generateUUIDv4()). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.6.10636.altinitytest (altinity build)) (from [::1]:46460) (comment: 02887_byteswap.sql) (query 42, line 57) (in query: SELECT byteSwap(generateUUIDv4());), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000a06a8eb 4. /build/src/Functions/FunctionUnaryArithmetic.h:332: DB::FunctionUnaryArithmetic::getReturnTypeImpl(std::vector, std::allocator>> const&) const @ 0x000000000b2098fd 5. /build/src/Functions/IFunction.h:520: DB::IFunction::getReturnTypeImpl(std::vector> const&) const @ 0x000000000a06a2de 6. /build/src/Functions/IFunction.cpp:645: DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x0000000012d96b0c 7. /build/src/Functions/IFunction.cpp:577: DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x0000000012d9669c 8. /build/src/Functions/IFunction.cpp:606: DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x0000000012d96edc 9. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3544: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000014033cc9 10. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3838: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000014019a9e 11. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3980: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000014018e31 12. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:4304: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000014042fa7 13. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5605: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000014013749 14. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000140127f9 15. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000014011fce 16. /build/src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000001406ce8a 17. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000014973b42 18. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000001497268d 19. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000014974d24 20. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001492924b 21. /build/src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88641 22. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 23. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 24. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 25. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 26. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 27. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 28. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 29. ? @ 0x00007fbc6213eac3 30. ? @ 0x00007fbc621d0850 2025.07.28 11:57:39.445467 [ 17371 ] {} TCPHandler: Code: 43. DB::Exception: Illegal type UUID of argument of function byteSwap: In scope SELECT byteSwap(generateUUIDv4()). (ILLEGAL_TYPE_OF_ARGUMENT), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000a06a8eb 4. /build/src/Functions/FunctionUnaryArithmetic.h:332: DB::FunctionUnaryArithmetic::getReturnTypeImpl(std::vector, std::allocator>> const&) const @ 0x000000000b2098fd 5. /build/src/Functions/IFunction.h:520: DB::IFunction::getReturnTypeImpl(std::vector> const&) const @ 0x000000000a06a2de 6. /build/src/Functions/IFunction.cpp:645: DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x0000000012d96b0c 7. /build/src/Functions/IFunction.cpp:577: DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x0000000012d9669c 8. /build/src/Functions/IFunction.cpp:606: DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x0000000012d96edc 9. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3544: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000014033cc9 10. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3838: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000014019a9e 11. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3980: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000014018e31 12. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:4304: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000014042fa7 13. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5605: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000014013749 14. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000140127f9 15. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000014011fce 16. /build/src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000001406ce8a 17. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000014973b42 18. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000001497268d 19. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000014974d24 20. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001492924b 21. /build/src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88641 22. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 23. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 24. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 25. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 26. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 27. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 28. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 29. ? @ 0x00007fbc6213eac3 30. ? @ 0x00007fbc621d0850 2025.07.28 11:57:39.479919 [ 17371 ] {808b8e45-fc44-408d-b491-e1334883fa0b} executeQuery: Code: 43. DB::Exception: Illegal type Decimal(9, 4) of argument of function byteSwap: In scope SELECT byteSwap(toDecimal32(2, 4)). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.6.10636.altinitytest (altinity build)) (from [::1]:46460) (comment: 02887_byteswap.sql) (query 43, line 58) (in query: SELECT byteSwap(toDecimal32(2, 4));), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000a06a8eb 4. /build/src/Functions/FunctionUnaryArithmetic.h:332: DB::FunctionUnaryArithmetic::getReturnTypeImpl(std::vector, std::allocator>> const&) const @ 0x000000000b2098fd 5. /build/src/Functions/IFunction.h:520: DB::IFunction::getReturnTypeImpl(std::vector> const&) const @ 0x000000000a06a2de 6. /build/src/Functions/IFunction.cpp:645: DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x0000000012d96b0c 7. /build/src/Functions/IFunction.cpp:577: DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x0000000012d9669c 8. /build/src/Functions/IFunction.cpp:606: DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x0000000012d96edc 9. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3544: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000014033cc9 10. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3838: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000014019a9e 11. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3980: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000014018e31 12. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:4304: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000014042fa7 13. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5605: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000014013749 14. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000140127f9 15. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000014011fce 16. /build/src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000001406ce8a 17. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000014973b42 18. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000001497268d 19. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000014974d24 20. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001492924b 21. /build/src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88641 22. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 23. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 24. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 25. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 26. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 27. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 28. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 29. ? @ 0x00007fbc6213eac3 30. ? @ 0x00007fbc621d0850 2025.07.28 11:57:39.484693 [ 17371 ] {} TCPHandler: Code: 43. DB::Exception: Illegal type Decimal(9, 4) of argument of function byteSwap: In scope SELECT byteSwap(toDecimal32(2, 4)). (ILLEGAL_TYPE_OF_ARGUMENT), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000a06a8eb 4. /build/src/Functions/FunctionUnaryArithmetic.h:332: DB::FunctionUnaryArithmetic::getReturnTypeImpl(std::vector, std::allocator>> const&) const @ 0x000000000b2098fd 5. /build/src/Functions/IFunction.h:520: DB::IFunction::getReturnTypeImpl(std::vector> const&) const @ 0x000000000a06a2de 6. /build/src/Functions/IFunction.cpp:645: DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x0000000012d96b0c 7. /build/src/Functions/IFunction.cpp:577: DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x0000000012d9669c 8. /build/src/Functions/IFunction.cpp:606: DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x0000000012d96edc 9. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3544: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000014033cc9 10. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3838: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000014019a9e 11. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3980: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000014018e31 12. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:4304: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000014042fa7 13. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5605: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000014013749 14. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000140127f9 15. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000014011fce 16. /build/src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000001406ce8a 17. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000014973b42 18. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000001497268d 19. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000014974d24 20. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001492924b 21. /build/src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88641 22. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 23. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 24. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 25. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 26. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 27. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 28. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 29. ? @ 0x00007fbc6213eac3 30. ? @ 0x00007fbc621d0850 2025.07.28 11:57:39.586097 [ 17371 ] {7830d12a-c7fa-4e45-b591-82e1ff600d91} executeQuery: Code: 48. DB::Exception: byteSwap() is not implemented for float datatype: In scope SELECT byteSwap(toFloat32(123.456)). (NOT_IMPLEMENTED) (version 25.3.6.10636.altinitytest (altinity build)) (from [::1]:46460) (comment: 02887_byteswap.sql) (query 44, line 59) (in query: SELECT byteSwap(toFloat32(123.456));), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x000000000a06b56b 4. /build/src/Functions/byteSwap.cpp:33: DB::(anonymous namespace)::ByteSwapImpl::apply(float) @ 0x000000000b20d166 5. /build/src/Functions/FunctionUnaryArithmetic.h:45: ? @ 0x000000000b20d094 6. /build/src/Functions/FunctionUnaryArithmetic.h:465: auto DB::FunctionUnaryArithmetic::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&)::operator()>(auto const&) const @ 0x000000000b209b6d 7. /build/src/Functions/castTypeToEither.h:12: DB::FunctionUnaryArithmetic::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000b208caf 8. /build/src/Functions/IFunction.h:437: DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000a069f2a 9. /build/src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000012d9965a 10. /build/src/Functions/IFunction.cpp:351: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d93b02 11. /build/src/Functions/IFunction.cpp:177: DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d93698 12. /build/src/Functions/IFunction.cpp:343: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d93aad 13. /build/src/Functions/IFunction.cpp:420: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d95059 14. /build/src/Functions/IFunction.cpp:498: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d95c72 15. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3567: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000014034494 16. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3838: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000014019a9e 17. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3980: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000014018e31 18. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:4304: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000014042fa7 19. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5605: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000014013749 20. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000140127f9 21. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000014011fce 22. /build/src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000001406ce8a 23. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000014973b42 24. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000001497268d 25. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000014974d24 26. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001492924b 27. /build/src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88641 28. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 29. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 30. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 31. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 2025.07.28 11:57:39.589932 [ 17371 ] {} TCPHandler: Code: 48. DB::Exception: byteSwap() is not implemented for float datatype: In scope SELECT byteSwap(toFloat32(123.456)). (NOT_IMPLEMENTED), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x000000000a06b56b 4. /build/src/Functions/byteSwap.cpp:33: DB::(anonymous namespace)::ByteSwapImpl::apply(float) @ 0x000000000b20d166 5. /build/src/Functions/FunctionUnaryArithmetic.h:45: ? @ 0x000000000b20d094 6. /build/src/Functions/FunctionUnaryArithmetic.h:465: auto DB::FunctionUnaryArithmetic::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&)::operator()>(auto const&) const @ 0x000000000b209b6d 7. /build/src/Functions/castTypeToEither.h:12: DB::FunctionUnaryArithmetic::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000b208caf 8. /build/src/Functions/IFunction.h:437: DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000a069f2a 9. /build/src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000012d9965a 10. /build/src/Functions/IFunction.cpp:351: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d93b02 11. /build/src/Functions/IFunction.cpp:177: DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d93698 12. /build/src/Functions/IFunction.cpp:343: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d93aad 13. /build/src/Functions/IFunction.cpp:420: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d95059 14. /build/src/Functions/IFunction.cpp:498: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d95c72 15. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3567: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000014034494 16. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3838: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000014019a9e 17. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3980: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000014018e31 18. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:4304: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000014042fa7 19. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5605: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000014013749 20. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000140127f9 21. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000014011fce 22. /build/src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000001406ce8a 23. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000014973b42 24. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000001497268d 25. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000014974d24 26. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001492924b 27. /build/src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88641 28. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 29. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 30. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 31. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 2025.07.28 11:57:39.648483 [ 17371 ] {e95544f4-326e-444e-bdae-981d6cf4b11d} executeQuery: Code: 48. DB::Exception: byteSwap() is not implemented for double datatype: In scope SELECT byteSwap(toFloat64(123.456)). (NOT_IMPLEMENTED) (version 25.3.6.10636.altinitytest (altinity build)) (from [::1]:46460) (comment: 02887_byteswap.sql) (query 45, line 60) (in query: SELECT byteSwap(toFloat64(123.456));), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x000000000a06b56b 4. /build/src/Functions/byteSwap.cpp:33: DB::(anonymous namespace)::ByteSwapImpl::apply(double) @ 0x000000000b20d366 5. /build/src/Functions/FunctionUnaryArithmetic.h:45: ? @ 0x000000000b20d294 6. /build/src/Functions/FunctionUnaryArithmetic.h:465: auto DB::FunctionUnaryArithmetic::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&)::operator()>(auto const&) const @ 0x000000000b209ced 7. /build/src/Functions/castTypeToEither.h:12: DB::FunctionUnaryArithmetic::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000b208cf7 8. /build/src/Functions/IFunction.h:437: DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000a069f2a 9. /build/src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000012d9965a 10. /build/src/Functions/IFunction.cpp:351: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d93b02 11. /build/src/Functions/IFunction.cpp:177: DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d93698 12. /build/src/Functions/IFunction.cpp:343: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d93aad 13. /build/src/Functions/IFunction.cpp:420: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d95059 14. /build/src/Functions/IFunction.cpp:498: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d95c72 15. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3567: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000014034494 16. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3838: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000014019a9e 17. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3980: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000014018e31 18. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:4304: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000014042fa7 19. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5605: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000014013749 20. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000140127f9 21. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000014011fce 22. /build/src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000001406ce8a 23. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000014973b42 24. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000001497268d 25. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000014974d24 26. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001492924b 27. /build/src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88641 28. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 29. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 30. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 31. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 2025.07.28 11:57:39.652100 [ 17371 ] {} TCPHandler: Code: 48. DB::Exception: byteSwap() is not implemented for double datatype: In scope SELECT byteSwap(toFloat64(123.456)). (NOT_IMPLEMENTED), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x000000000a06b56b 4. /build/src/Functions/byteSwap.cpp:33: DB::(anonymous namespace)::ByteSwapImpl::apply(double) @ 0x000000000b20d366 5. /build/src/Functions/FunctionUnaryArithmetic.h:45: ? @ 0x000000000b20d294 6. /build/src/Functions/FunctionUnaryArithmetic.h:465: auto DB::FunctionUnaryArithmetic::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&)::operator()>(auto const&) const @ 0x000000000b209ced 7. /build/src/Functions/castTypeToEither.h:12: DB::FunctionUnaryArithmetic::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000b208cf7 8. /build/src/Functions/IFunction.h:437: DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000a069f2a 9. /build/src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000012d9965a 10. /build/src/Functions/IFunction.cpp:351: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d93b02 11. /build/src/Functions/IFunction.cpp:177: DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d93698 12. /build/src/Functions/IFunction.cpp:343: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d93aad 13. /build/src/Functions/IFunction.cpp:420: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d95059 14. /build/src/Functions/IFunction.cpp:498: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d95c72 15. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3567: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000014034494 16. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3838: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000014019a9e 17. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3980: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000014018e31 18. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:4304: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000014042fa7 19. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5605: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000014013749 20. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000140127f9 21. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000014011fce 22. /build/src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000001406ce8a 23. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000014973b42 24. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000001497268d 25. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000014974d24 26. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001492924b 27. /build/src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88641 28. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 29. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 30. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 31. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 2025.07.28 11:57:39.725854 [ 3966 ] {} test_13.rmt2 (7f9b740d-015c-470e-8cc6-8ba33be0dc63): auto DB::StorageReplicatedMergeTree::processQueueEntry(ReplicatedMergeTreeQueue::SelectedEntryPtr)::(anonymous class)::operator()(LogEntryPtr &) const: Code: 86. DB::HTTPException: Received error from remote server http://146b4357c08d:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Ftest%2F01165%2Ftest_13%2Frmt%2Freplicas%2F1&part=20250728_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.6.10636.altinitytest (altinity build)) '. (RECEIVED_ERROR_FROM_REMOTE_IO_SERVER), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.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 const&, int&&, String const&, unsigned long&&, String const&) @ 0x000000000feda8d9 4. /build/src/IO/HTTPCommon.cpp:104: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x000000000feda6e2 5. /build/src/IO/HTTPCommon.cpp:93: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x000000000feda537 6. /build/src/IO/ReadWriteBufferFromHTTP.cpp:277: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x000000001184a4c4 7. /build/src/IO/ReadWriteBufferFromHTTP.cpp:285: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x000000001184a615 8. /build/src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x000000001184ae59 9. /build/src/IO/ReadWriteBufferFromHTTP.cpp:472: void std::__function::__policy_invoker::__call_impl[abi:se190107]>(std::__function::__policy_storage const*) @ 0x000000001184cedd 10. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001184858b 11. /build/src/IO/ReadWriteBufferFromHTTP.cpp:465: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x000000001184bf0b 12. /build/src/IO/ReadBuffer.h:60: DB::ReadBuffer::next() @ 0x000000000a148c7b 13. /build/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) @ 0x0000000011849fb2 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]>&)>&, 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&) @ 0x0000000011841980 15. /build/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) @ 0x000000001621208e 16. /build/src/Storages/StorageReplicatedMergeTree.cpp:5228: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl[abi:se190107] const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000015f9a5fe 17. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000015ed8bfd 18. /build/src/Storages/StorageReplicatedMergeTree.cpp:2514: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x0000000015ec9aab 19. /build/src/Storages/StorageReplicatedMergeTree.cpp:2349: DB::StorageReplicatedMergeTree::executeLogEntry(DB::ReplicatedMergeTreeLogEntry&) @ 0x0000000015eba91b 20. /build/src/Storages/StorageReplicatedMergeTree.cpp:3876: bool std::__function::__policy_invoker&)>::__call_impl[abi:se190107])::$_1, bool (std::shared_ptr&)>>(std::__function::__policy_storage const*, std::shared_ptr&) @ 0x0000000015f9837e 21. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000165d6fc3 22. /build/src/Storages/StorageReplicatedMergeTree.cpp:3872: DB::StorageReplicatedMergeTree::processQueueEntry(std::shared_ptr) @ 0x0000000015efc18a 23. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001624c1b2 24. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000162f9c70 25. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x00000000162fa55a 26. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc6653 27. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000000fccc4c3 28. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc3d92 29. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fcca080 30. ? @ 0x00007fbc6213eac3 31. ? @ 0x00007fbc621d0850 (version 25.3.6.10636.altinitytest (altinity build)) 2025.07.28 11:57:40.741298 [ 3977 ] {} test_13.rmt2 (7f9b740d-015c-470e-8cc6-8ba33be0dc63): auto DB::StorageReplicatedMergeTree::processQueueEntry(ReplicatedMergeTreeQueue::SelectedEntryPtr)::(anonymous class)::operator()(LogEntryPtr &) const: Code: 86. DB::HTTPException: Received error from remote server http://146b4357c08d:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Ftest%2F01165%2Ftest_13%2Frmt%2Freplicas%2F1&part=20250728_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.6.10636.altinitytest (altinity build)) '. (RECEIVED_ERROR_FROM_REMOTE_IO_SERVER), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.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 const&, int&&, String const&, unsigned long&&, String const&) @ 0x000000000feda8d9 4. /build/src/IO/HTTPCommon.cpp:104: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x000000000feda6e2 5. /build/src/IO/HTTPCommon.cpp:93: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x000000000feda537 6. /build/src/IO/ReadWriteBufferFromHTTP.cpp:277: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x000000001184a4c4 7. /build/src/IO/ReadWriteBufferFromHTTP.cpp:285: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x000000001184a615 8. /build/src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x000000001184ae59 9. /build/src/IO/ReadWriteBufferFromHTTP.cpp:472: void std::__function::__policy_invoker::__call_impl[abi:se190107]>(std::__function::__policy_storage const*) @ 0x000000001184cedd 10. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001184858b 11. /build/src/IO/ReadWriteBufferFromHTTP.cpp:465: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x000000001184bf0b 12. /build/src/IO/ReadBuffer.h:60: DB::ReadBuffer::next() @ 0x000000000a148c7b 13. /build/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) @ 0x0000000011849fb2 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]>&)>&, 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&) @ 0x0000000011841980 15. /build/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) @ 0x000000001621208e 16. /build/src/Storages/StorageReplicatedMergeTree.cpp:5228: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl[abi:se190107] const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000015f9a5fe 17. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000015ed8bfd 18. /build/src/Storages/StorageReplicatedMergeTree.cpp:2514: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x0000000015ec9aab 19. /build/src/Storages/StorageReplicatedMergeTree.cpp:2349: DB::StorageReplicatedMergeTree::executeLogEntry(DB::ReplicatedMergeTreeLogEntry&) @ 0x0000000015eba91b 20. /build/src/Storages/StorageReplicatedMergeTree.cpp:3876: bool std::__function::__policy_invoker&)>::__call_impl[abi:se190107])::$_1, bool (std::shared_ptr&)>>(std::__function::__policy_storage const*, std::shared_ptr&) @ 0x0000000015f9837e 21. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000165d6fc3 22. /build/src/Storages/StorageReplicatedMergeTree.cpp:3872: DB::StorageReplicatedMergeTree::processQueueEntry(std::shared_ptr) @ 0x0000000015efc18a 23. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001624c1b2 24. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000162f9c70 25. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x00000000162fa55a 26. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc6653 27. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000000fccc4c3 28. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc3d92 29. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fcca080 30. ? @ 0x00007fbc6213eac3 31. ? @ 0x00007fbc621d0850 (version 25.3.6.10636.altinitytest (altinity build)) 2025.07.28 11:57:41.397597 [ 4900 ] {f6a60cb1-20a3-482b-a640-cc29d1068dda} 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.6.10636.altinitytest (altinity build)) (from [::1]:46668) (comment: 00927_asof_join_other_types.gen.sql) (query 8, line 13) (in query: SELECT k, t, a, b FROM A ASOF LEFT JOIN B USING(k,t) ORDER BY (k,t) SETTINGS join_algorithm = 'full_sorting_merge';), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000000a074fcb 4. /build/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) @ 0x00000000149c5c9b 5. /build/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) @ 0x0000000016de9821 6. /build/src/Processors/QueryPlan/Optimizations/optimizeJoin.cpp:251: DB::QueryPlanOptimizations::convertLogicalJoinToPhysical(DB::QueryPlan::Node&, std::list>&, DB::QueryPlanOptimizationSettings const&, std::optional) @ 0x0000000016eb5ce9 7. /build/src/Processors/QueryPlan/Optimizations/optimizeTree.cpp:158: DB::QueryPlanOptimizations::optimizeTreeSecondPass(DB::QueryPlanOptimizationSettings const&, DB::QueryPlan::Node&, std::list>&) @ 0x0000000016ead357 8. /build/src/Processors/QueryPlan/QueryPlan.cpp:487: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x0000000016e0055c 9. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:275: DB::InterpreterSelectQueryAnalyzer::buildQueryPipeline() @ 0x0000000014974614 10. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:242: DB::InterpreterSelectQueryAnalyzer::execute() @ 0x000000001497439e 11. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88dc9 12. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 13. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 14. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 15. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 16. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 17. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 18. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 19. ? @ 0x00007fbc6213eac3 20. ? @ 0x00007fbc621d0850 2025.07.28 11:57:41.436413 [ 4900 ] {} 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. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000000a074fcb 4. /build/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) @ 0x00000000149c5c9b 5. /build/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) @ 0x0000000016de9821 6. /build/src/Processors/QueryPlan/Optimizations/optimizeJoin.cpp:251: DB::QueryPlanOptimizations::convertLogicalJoinToPhysical(DB::QueryPlan::Node&, std::list>&, DB::QueryPlanOptimizationSettings const&, std::optional) @ 0x0000000016eb5ce9 7. /build/src/Processors/QueryPlan/Optimizations/optimizeTree.cpp:158: DB::QueryPlanOptimizations::optimizeTreeSecondPass(DB::QueryPlanOptimizationSettings const&, DB::QueryPlan::Node&, std::list>&) @ 0x0000000016ead357 8. /build/src/Processors/QueryPlan/QueryPlan.cpp:487: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x0000000016e0055c 9. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:275: DB::InterpreterSelectQueryAnalyzer::buildQueryPipeline() @ 0x0000000014974614 10. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:242: DB::InterpreterSelectQueryAnalyzer::execute() @ 0x000000001497439e 11. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88dc9 12. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 13. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 14. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 15. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 16. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 17. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 18. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 19. ? @ 0x00007fbc6213eac3 20. ? @ 0x00007fbc621d0850 2025.07.28 11:57:41.623374 [ 3283 ] {4380d972-71c9-4130-9e6a-31829cfc23dc} executeQuery: Code: 36. DB::Exception: Bad format %X in function printf with 123.123 Float64 Const(size = 1, Float64(size = 1)) as input argument, reason: invalid format specifier: In scope SELECT printf('%%X: %X', 123.123). (BAD_ARGUMENTS) (version 25.3.6.10636.altinitytest (altinity build)) (from [::1]:46534) (comment: 03203_function_printf.sql) (query 30, line 45) (in query: select printf('%%X: %X', 123.123);), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception>&, String, String, char const*>(int, FormatStringHelperImpl>&>::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, std::basic_string_view>&, String&&, String&&, char const*&&) @ 0x000000000e588bcb 4. /build/src/Functions/printf.cpp:235: DB::(anonymous namespace)::FunctionPrintf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000e5850ab 5. /build/src/Functions/IFunction.h:437: DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000a069f2a 6. /build/src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000012d9965a 7. /build/src/Functions/IFunction.cpp:351: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d93b02 8. /build/src/Functions/IFunction.cpp:420: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d95059 9. /build/src/Functions/IFunction.cpp:498: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d95c72 10. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3567: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000014034494 11. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3838: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000014019a9e 12. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3980: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000014018e31 13. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:4304: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000014042fa7 14. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5605: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000014013749 15. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000140127f9 16. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000014011fce 17. /build/src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000001406ce8a 18. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000014973b42 19. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000001497268d 20. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000014974d24 21. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001492924b 22. /build/src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88641 23. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 24. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 25. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 26. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 27. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 28. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 29. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 30. ? @ 0x00007fbc6213eac3 31. ? @ 0x00007fbc621d0850 2025.07.28 11:57:41.634219 [ 3283 ] {} TCPHandler: Code: 36. DB::Exception: Bad format %X in function printf with 123.123 Float64 Const(size = 1, Float64(size = 1)) as input argument, reason: invalid format specifier: In scope SELECT printf('%%X: %X', 123.123). (BAD_ARGUMENTS), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception>&, String, String, char const*>(int, FormatStringHelperImpl>&>::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, std::basic_string_view>&, String&&, String&&, char const*&&) @ 0x000000000e588bcb 4. /build/src/Functions/printf.cpp:235: DB::(anonymous namespace)::FunctionPrintf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000e5850ab 5. /build/src/Functions/IFunction.h:437: DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000a069f2a 6. /build/src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000012d9965a 7. /build/src/Functions/IFunction.cpp:351: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d93b02 8. /build/src/Functions/IFunction.cpp:420: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d95059 9. /build/src/Functions/IFunction.cpp:498: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d95c72 10. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3567: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000014034494 11. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3838: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000014019a9e 12. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3980: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000014018e31 13. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:4304: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000014042fa7 14. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5605: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000014013749 15. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000140127f9 16. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000014011fce 17. /build/src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000001406ce8a 18. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000014973b42 19. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000001497268d 20. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000014974d24 21. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001492924b 22. /build/src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88641 23. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 24. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 25. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 26. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 27. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 28. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 29. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 30. ? @ 0x00007fbc6213eac3 31. ? @ 0x00007fbc621d0850 2025.07.28 11:57:41.696135 [ 3283 ] {0a6ff70e-2ff3-4000-b6e5-50c2ba975eb7} executeQuery: Code: 36. DB::Exception: Bad format %A in function printf with 'abc' String Const(size = 1, String(size = 1)) as input argument, reason: invalid format specifier: In scope SELECT printf('%%A: %A', 'abc'). (BAD_ARGUMENTS) (version 25.3.6.10636.altinitytest (altinity build)) (from [::1]:46534) (comment: 03203_function_printf.sql) (query 31, line 46) (in query: select printf('%%A: %A', 'abc');), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception>&, String, String, char const*>(int, FormatStringHelperImpl>&>::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, std::basic_string_view>&, String&&, String&&, char const*&&) @ 0x000000000e588bcb 4. /build/src/Functions/printf.cpp:235: DB::(anonymous namespace)::FunctionPrintf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000e5850ab 5. /build/src/Functions/IFunction.h:437: DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000a069f2a 6. /build/src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000012d9965a 7. /build/src/Functions/IFunction.cpp:351: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d93b02 8. /build/src/Functions/IFunction.cpp:420: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d95059 9. /build/src/Functions/IFunction.cpp:498: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d95c72 10. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3567: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000014034494 11. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3838: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000014019a9e 12. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3980: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000014018e31 13. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:4304: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000014042fa7 14. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5605: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000014013749 15. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000140127f9 16. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000014011fce 17. /build/src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000001406ce8a 18. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000014973b42 19. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000001497268d 20. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000014974d24 21. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001492924b 22. /build/src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88641 23. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 24. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 25. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 26. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 27. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 28. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 29. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 30. ? @ 0x00007fbc6213eac3 31. ? @ 0x00007fbc621d0850 2025.07.28 11:57:41.719169 [ 3283 ] {} TCPHandler: Code: 36. DB::Exception: Bad format %A in function printf with 'abc' String Const(size = 1, String(size = 1)) as input argument, reason: invalid format specifier: In scope SELECT printf('%%A: %A', 'abc'). (BAD_ARGUMENTS), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception>&, String, String, char const*>(int, FormatStringHelperImpl>&>::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, std::basic_string_view>&, String&&, String&&, char const*&&) @ 0x000000000e588bcb 4. /build/src/Functions/printf.cpp:235: DB::(anonymous namespace)::FunctionPrintf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000e5850ab 5. /build/src/Functions/IFunction.h:437: DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000a069f2a 6. /build/src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000012d9965a 7. /build/src/Functions/IFunction.cpp:351: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d93b02 8. /build/src/Functions/IFunction.cpp:420: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d95059 9. /build/src/Functions/IFunction.cpp:498: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d95c72 10. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3567: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000014034494 11. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3838: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000014019a9e 12. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3980: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000014018e31 13. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:4304: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000014042fa7 14. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5605: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000014013749 15. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000140127f9 16. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000014011fce 17. /build/src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000001406ce8a 18. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000014973b42 19. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000001497268d 20. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000014974d24 21. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001492924b 22. /build/src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88641 23. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 24. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 25. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 26. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 27. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 28. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 29. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 30. ? @ 0x00007fbc6213eac3 31. ? @ 0x00007fbc621d0850 2025.07.28 11:57:41.825790 [ 3969 ] {} test_13.rmt2 (7f9b740d-015c-470e-8cc6-8ba33be0dc63): auto DB::StorageReplicatedMergeTree::processQueueEntry(ReplicatedMergeTreeQueue::SelectedEntryPtr)::(anonymous class)::operator()(LogEntryPtr &) const: Code: 86. DB::HTTPException: Received error from remote server http://146b4357c08d:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Ftest%2F01165%2Ftest_13%2Frmt%2Freplicas%2F1&part=20250728_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.6.10636.altinitytest (altinity build)) '. (RECEIVED_ERROR_FROM_REMOTE_IO_SERVER), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.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 const&, int&&, String const&, unsigned long&&, String const&) @ 0x000000000feda8d9 4. /build/src/IO/HTTPCommon.cpp:104: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x000000000feda6e2 5. /build/src/IO/HTTPCommon.cpp:93: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x000000000feda537 6. /build/src/IO/ReadWriteBufferFromHTTP.cpp:277: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x000000001184a4c4 7. /build/src/IO/ReadWriteBufferFromHTTP.cpp:285: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x000000001184a615 8. /build/src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x000000001184ae59 9. /build/src/IO/ReadWriteBufferFromHTTP.cpp:472: void std::__function::__policy_invoker::__call_impl[abi:se190107]>(std::__function::__policy_storage const*) @ 0x000000001184cedd 10. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001184858b 11. /build/src/IO/ReadWriteBufferFromHTTP.cpp:465: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x000000001184bf0b 12. /build/src/IO/ReadBuffer.h:60: DB::ReadBuffer::next() @ 0x000000000a148c7b 13. /build/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) @ 0x0000000011849fb2 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]>&)>&, 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&) @ 0x0000000011841980 15. /build/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) @ 0x000000001621208e 16. /build/src/Storages/StorageReplicatedMergeTree.cpp:5228: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl[abi:se190107] const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000015f9a5fe 17. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000015ed8bfd 18. /build/src/Storages/StorageReplicatedMergeTree.cpp:2514: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x0000000015ec9aab 19. /build/src/Storages/StorageReplicatedMergeTree.cpp:2349: DB::StorageReplicatedMergeTree::executeLogEntry(DB::ReplicatedMergeTreeLogEntry&) @ 0x0000000015eba91b 20. /build/src/Storages/StorageReplicatedMergeTree.cpp:3876: bool std::__function::__policy_invoker&)>::__call_impl[abi:se190107])::$_1, bool (std::shared_ptr&)>>(std::__function::__policy_storage const*, std::shared_ptr&) @ 0x0000000015f9837e 21. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000165d6fc3 22. /build/src/Storages/StorageReplicatedMergeTree.cpp:3872: DB::StorageReplicatedMergeTree::processQueueEntry(std::shared_ptr) @ 0x0000000015efc18a 23. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001624c1b2 24. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000162f9c70 25. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x00000000162fa55a 26. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc6653 27. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000000fccc4c3 28. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc3d92 29. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fcca080 30. ? @ 0x00007fbc6213eac3 31. ? @ 0x00007fbc621d0850 (version 25.3.6.10636.altinitytest (altinity build)) 2025.07.28 11:57:41.848987 [ 3283 ] {3fd76a71-e79e-4475-8f85-36e4eb2f9c2a} executeQuery: Code: 36. DB::Exception: Bad format %s in function printf with 100 UInt8 Const(size = 1, UInt8(size = 1)) as input argument, reason: invalid format specifier: In scope SELECT printf('%%s: %s', 100). (BAD_ARGUMENTS) (version 25.3.6.10636.altinitytest (altinity build)) (from [::1]:46534) (comment: 03203_function_printf.sql) (query 32, line 47) (in query: select printf('%%s: %s', 100);), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception>&, String, String, char const*>(int, FormatStringHelperImpl>&>::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, std::basic_string_view>&, String&&, String&&, char const*&&) @ 0x000000000e588bcb 4. /build/src/Functions/printf.cpp:235: DB::(anonymous namespace)::FunctionPrintf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000e5850ab 5. /build/src/Functions/IFunction.h:437: DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000a069f2a 6. /build/src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000012d9965a 7. /build/src/Functions/IFunction.cpp:351: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d93b02 8. /build/src/Functions/IFunction.cpp:420: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d95059 9. /build/src/Functions/IFunction.cpp:498: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d95c72 10. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3567: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000014034494 11. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3838: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000014019a9e 12. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3980: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000014018e31 13. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:4304: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000014042fa7 14. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5605: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000014013749 15. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000140127f9 16. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000014011fce 17. /build/src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000001406ce8a 18. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000014973b42 19. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000001497268d 20. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000014974d24 21. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001492924b 22. /build/src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88641 23. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 24. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 25. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 26. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 27. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 28. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 29. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 30. ? @ 0x00007fbc6213eac3 31. ? @ 0x00007fbc621d0850 2025.07.28 11:57:41.865087 [ 3283 ] {} TCPHandler: Code: 36. DB::Exception: Bad format %s in function printf with 100 UInt8 Const(size = 1, UInt8(size = 1)) as input argument, reason: invalid format specifier: In scope SELECT printf('%%s: %s', 100). (BAD_ARGUMENTS), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception>&, String, String, char const*>(int, FormatStringHelperImpl>&>::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, std::basic_string_view>&, String&&, String&&, char const*&&) @ 0x000000000e588bcb 4. /build/src/Functions/printf.cpp:235: DB::(anonymous namespace)::FunctionPrintf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000e5850ab 5. /build/src/Functions/IFunction.h:437: DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000a069f2a 6. /build/src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000012d9965a 7. /build/src/Functions/IFunction.cpp:351: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d93b02 8. /build/src/Functions/IFunction.cpp:420: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d95059 9. /build/src/Functions/IFunction.cpp:498: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d95c72 10. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3567: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000014034494 11. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3838: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000014019a9e 12. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3980: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000014018e31 13. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:4304: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000014042fa7 14. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5605: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000014013749 15. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000140127f9 16. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000014011fce 17. /build/src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000001406ce8a 18. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000014973b42 19. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000001497268d 20. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000014974d24 21. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001492924b 22. /build/src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88641 23. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 24. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 25. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 26. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 27. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 28. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 29. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 30. ? @ 0x00007fbc6213eac3 31. ? @ 0x00007fbc621d0850 2025.07.28 11:57:41.924888 [ 3283 ] {f7fd8449-0460-49f7-9886-dbd1224b610d} executeQuery: Code: 36. DB::Exception: Bad format %n in function printf with 100 UInt8 Const(size = 1, UInt8(size = 1)) as input argument, reason: invalid format specifier: In scope SELECT printf('%%n: %n', 100). (BAD_ARGUMENTS) (version 25.3.6.10636.altinitytest (altinity build)) (from [::1]:46534) (comment: 03203_function_printf.sql) (query 33, line 48) (in query: select printf('%%n: %n', 100);), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception>&, String, String, char const*>(int, FormatStringHelperImpl>&>::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, std::basic_string_view>&, String&&, String&&, char const*&&) @ 0x000000000e588bcb 4. /build/src/Functions/printf.cpp:235: DB::(anonymous namespace)::FunctionPrintf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000e5850ab 5. /build/src/Functions/IFunction.h:437: DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000a069f2a 6. /build/src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000012d9965a 7. /build/src/Functions/IFunction.cpp:351: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d93b02 8. /build/src/Functions/IFunction.cpp:420: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d95059 9. /build/src/Functions/IFunction.cpp:498: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d95c72 10. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3567: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000014034494 11. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3838: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000014019a9e 12. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3980: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000014018e31 13. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:4304: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000014042fa7 14. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5605: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000014013749 15. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000140127f9 16. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000014011fce 17. /build/src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000001406ce8a 18. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000014973b42 19. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000001497268d 20. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000014974d24 21. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001492924b 22. /build/src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88641 23. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 24. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 25. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 26. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 27. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 28. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 29. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 30. ? @ 0x00007fbc6213eac3 31. ? @ 0x00007fbc621d0850 2025.07.28 11:57:41.928824 [ 3283 ] {} TCPHandler: Code: 36. DB::Exception: Bad format %n in function printf with 100 UInt8 Const(size = 1, UInt8(size = 1)) as input argument, reason: invalid format specifier: In scope SELECT printf('%%n: %n', 100). (BAD_ARGUMENTS), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception>&, String, String, char const*>(int, FormatStringHelperImpl>&>::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, std::basic_string_view>&, String&&, String&&, char const*&&) @ 0x000000000e588bcb 4. /build/src/Functions/printf.cpp:235: DB::(anonymous namespace)::FunctionPrintf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000e5850ab 5. /build/src/Functions/IFunction.h:437: DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000a069f2a 6. /build/src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000012d9965a 7. /build/src/Functions/IFunction.cpp:351: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d93b02 8. /build/src/Functions/IFunction.cpp:420: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d95059 9. /build/src/Functions/IFunction.cpp:498: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d95c72 10. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3567: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000014034494 11. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3838: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000014019a9e 12. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3980: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000014018e31 13. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:4304: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000014042fa7 14. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5605: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000014013749 15. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000140127f9 16. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000014011fce 17. /build/src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000001406ce8a 18. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000014973b42 19. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000001497268d 20. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000014974d24 21. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001492924b 22. /build/src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88641 23. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 24. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 25. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 26. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 27. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 28. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 29. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 30. ? @ 0x00007fbc6213eac3 31. ? @ 0x00007fbc621d0850 2025.07.28 11:57:42.024373 [ 3283 ] {486c119a-0bcc-4fc3-93d7-5f11be817278} executeQuery: Code: 36. DB::Exception: Bad format %f in function printf with 0 UInt8 Const(size = 1, UInt8(size = 1)) as input argument, reason: invalid format specifier: In scope SELECT printf('%%f: %f', 0). (BAD_ARGUMENTS) (version 25.3.6.10636.altinitytest (altinity build)) (from [::1]:46534) (comment: 03203_function_printf.sql) (query 34, line 49) (in query: select printf('%%f: %f', 0);), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception>&, String, String, char const*>(int, FormatStringHelperImpl>&>::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, std::basic_string_view>&, String&&, String&&, char const*&&) @ 0x000000000e588bcb 4. /build/src/Functions/printf.cpp:235: DB::(anonymous namespace)::FunctionPrintf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000e5850ab 5. /build/src/Functions/IFunction.h:437: DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000a069f2a 6. /build/src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000012d9965a 7. /build/src/Functions/IFunction.cpp:351: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d93b02 8. /build/src/Functions/IFunction.cpp:420: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d95059 9. /build/src/Functions/IFunction.cpp:498: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d95c72 10. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3567: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000014034494 11. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3838: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000014019a9e 12. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3980: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000014018e31 13. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:4304: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000014042fa7 14. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5605: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000014013749 15. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000140127f9 16. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000014011fce 17. /build/src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000001406ce8a 18. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000014973b42 19. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000001497268d 20. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000014974d24 21. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001492924b 22. /build/src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88641 23. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 24. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 25. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 26. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 27. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 28. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 29. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 30. ? @ 0x00007fbc6213eac3 31. ? @ 0x00007fbc621d0850 2025.07.28 11:57:42.027621 [ 3283 ] {} TCPHandler: Code: 36. DB::Exception: Bad format %f in function printf with 0 UInt8 Const(size = 1, UInt8(size = 1)) as input argument, reason: invalid format specifier: In scope SELECT printf('%%f: %f', 0). (BAD_ARGUMENTS), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception>&, String, String, char const*>(int, FormatStringHelperImpl>&>::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, std::basic_string_view>&, String&&, String&&, char const*&&) @ 0x000000000e588bcb 4. /build/src/Functions/printf.cpp:235: DB::(anonymous namespace)::FunctionPrintf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000e5850ab 5. /build/src/Functions/IFunction.h:437: DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000a069f2a 6. /build/src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000012d9965a 7. /build/src/Functions/IFunction.cpp:351: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d93b02 8. /build/src/Functions/IFunction.cpp:420: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d95059 9. /build/src/Functions/IFunction.cpp:498: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d95c72 10. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3567: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000014034494 11. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3838: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000014019a9e 12. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3980: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000014018e31 13. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:4304: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000014042fa7 14. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5605: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000014013749 15. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000140127f9 16. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000014011fce 17. /build/src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000001406ce8a 18. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000014973b42 19. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000001497268d 20. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000014974d24 21. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001492924b 22. /build/src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88641 23. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 24. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 25. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 26. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 27. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 28. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 29. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 30. ? @ 0x00007fbc6213eac3 31. ? @ 0x00007fbc621d0850 2025.07.28 11:57:42.063752 [ 3971 ] {} test_13.rmt2 (7f9b740d-015c-470e-8cc6-8ba33be0dc63): auto DB::StorageReplicatedMergeTree::processQueueEntry(ReplicatedMergeTreeQueue::SelectedEntryPtr)::(anonymous class)::operator()(LogEntryPtr &) const: Code: 86. DB::HTTPException: Received error from remote server http://146b4357c08d:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Ftest%2F01165%2Ftest_13%2Frmt%2Freplicas%2F1&part=20250728_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.6.10636.altinitytest (altinity build)) '. (RECEIVED_ERROR_FROM_REMOTE_IO_SERVER), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.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 const&, int&&, String const&, unsigned long&&, String const&) @ 0x000000000feda8d9 4. /build/src/IO/HTTPCommon.cpp:104: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x000000000feda6e2 5. /build/src/IO/HTTPCommon.cpp:93: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x000000000feda537 6. /build/src/IO/ReadWriteBufferFromHTTP.cpp:277: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x000000001184a4c4 7. /build/src/IO/ReadWriteBufferFromHTTP.cpp:285: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x000000001184a615 8. /build/src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x000000001184ae59 9. /build/src/IO/ReadWriteBufferFromHTTP.cpp:472: void std::__function::__policy_invoker::__call_impl[abi:se190107]>(std::__function::__policy_storage const*) @ 0x000000001184cedd 10. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001184858b 11. /build/src/IO/ReadWriteBufferFromHTTP.cpp:465: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x000000001184bf0b 12. /build/src/IO/ReadBuffer.h:60: DB::ReadBuffer::next() @ 0x000000000a148c7b 13. /build/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) @ 0x0000000011849fb2 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]>&)>&, 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&) @ 0x0000000011841980 15. /build/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) @ 0x000000001621208e 16. /build/src/Storages/StorageReplicatedMergeTree.cpp:5228: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl[abi:se190107] const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000015f9a5fe 17. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000015ed8bfd 18. /build/src/Storages/StorageReplicatedMergeTree.cpp:2514: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x0000000015ec9aab 19. /build/src/Storages/StorageReplicatedMergeTree.cpp:2349: DB::StorageReplicatedMergeTree::executeLogEntry(DB::ReplicatedMergeTreeLogEntry&) @ 0x0000000015eba91b 20. /build/src/Storages/StorageReplicatedMergeTree.cpp:3876: bool std::__function::__policy_invoker&)>::__call_impl[abi:se190107])::$_1, bool (std::shared_ptr&)>>(std::__function::__policy_storage const*, std::shared_ptr&) @ 0x0000000015f9837e 21. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000165d6fc3 22. /build/src/Storages/StorageReplicatedMergeTree.cpp:3872: DB::StorageReplicatedMergeTree::processQueueEntry(std::shared_ptr) @ 0x0000000015efc18a 23. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001624c1b2 24. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000162f9c70 25. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x00000000162fa55a 26. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc6653 27. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000000fccc4c3 28. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc3d92 29. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fcca080 30. ? @ 0x00007fbc6213eac3 31. ? @ 0x00007fbc621d0850 (version 25.3.6.10636.altinitytest (altinity build)) 2025.07.28 11:57:42.284936 [ 17203 ] {f9a0d72c-3dee-4247-abab-7f1d208293ee} 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.6.10636.altinitytest (altinity build)) (from [::1]:54186) (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. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x000000000a06b56b 4. /build/src/Functions/throwIf.cpp:153: DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000e8193b5 5. /build/src/Functions/IFunctionAdaptors.cpp:10: DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000012d995fa 6. /build/src/Functions/IFunction.cpp:353: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d93b52 7. /build/src/Functions/IFunction.cpp:420: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d95059 8. /build/src/Functions/IFunction.cpp:498: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d95c72 9. /build/src/Interpreters/ExpressionActions.cpp:636: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x00000000145176f3 10. /build/src/Processors/Transforms/ExpressionTransform.cpp:25: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x0000000016c0b34c 11. /build/src/Processors/ISimpleTransform.h:33: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000011a9a453 12. /build/src/Processors/ISimpleTransform.cpp:89: DB::ISimpleTransform::work() @ 0x000000001699fca0 13. /build/src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x00000000169bd00f 14. /build/src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x00000000169b2105 15. /build/src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeSingleThread(unsigned long) @ 0x00000000169b23be 16. /build/src/Processors/Executors/PipelineExecutor.cpp:454: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x00000000169b0be7 17. /build/src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x00000000169b03f4 18. /build/src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:se190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169bfeab 19. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc3d92 20. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fcca080 21. ? @ 0x00007fbc6213eac3 22. ? @ 0x00007fbc621d0850 2025.07.28 11:57:42.290588 [ 17203 ] {} 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. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x000000000a06b56b 4. /build/src/Functions/throwIf.cpp:153: DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000e8193b5 5. /build/src/Functions/IFunctionAdaptors.cpp:10: DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000012d995fa 6. /build/src/Functions/IFunction.cpp:353: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d93b52 7. /build/src/Functions/IFunction.cpp:420: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d95059 8. /build/src/Functions/IFunction.cpp:498: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d95c72 9. /build/src/Interpreters/ExpressionActions.cpp:636: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x00000000145176f3 10. /build/src/Processors/Transforms/ExpressionTransform.cpp:25: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x0000000016c0b34c 11. /build/src/Processors/ISimpleTransform.h:33: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000011a9a453 12. /build/src/Processors/ISimpleTransform.cpp:89: DB::ISimpleTransform::work() @ 0x000000001699fca0 13. /build/src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x00000000169bd00f 14. /build/src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x00000000169b2105 15. /build/src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeSingleThread(unsigned long) @ 0x00000000169b23be 16. /build/src/Processors/Executors/PipelineExecutor.cpp:454: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x00000000169b0be7 17. /build/src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x00000000169b03f4 18. /build/src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:se190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169bfeab 19. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc3d92 20. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fcca080 21. ? @ 0x00007fbc6213eac3 22. ? @ 0x00007fbc621d0850 Job's origin stack trace: 0. /build/src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000000fc33b84 1. /build/src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000000fcc2ea7 2. /build/src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fcc535c 3. /build/src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000000fcc584d 4. /build/src/Common/ThreadPool.h:279: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x00000000169bf193 5. /build/src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x00000000169bf518 6. /build/src/Server/TCPHandler.cpp:1237: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x00000000168f1525 7. /build/src/Server/TCPHandler.cpp:678: DB::TCPHandler::runImpl() @ 0x00000000168e68e5 8. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 9. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 10. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 11. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 12. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 13. ? @ 0x00007fbc6213eac3 14. ? @ 0x00007fbc621d0850 2025.07.28 11:57:42.452503 [ 17203 ] {bcaa59c2-201b-4c50-aec8-47d79eaf5cda} 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.6.10636.altinitytest (altinity build)) (from [::1]:54186) (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. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x000000000a06b56b 4. /build/src/Functions/throwIf.cpp:153: DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000e8193b5 5. /build/src/Functions/IFunctionAdaptors.cpp:10: DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000012d995fa 6. /build/src/Functions/IFunction.cpp:353: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d93b52 7. /build/src/Functions/IFunction.cpp:420: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d95059 8. /build/src/Functions/IFunction.cpp:498: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d95c72 9. /build/src/Interpreters/ExpressionActions.cpp:636: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x00000000145176f3 10. /build/src/Processors/Transforms/ExpressionTransform.cpp:25: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x0000000016c0b34c 11. /build/src/Processors/ISimpleTransform.h:33: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000011a9a453 12. /build/src/Processors/ISimpleTransform.cpp:89: DB::ISimpleTransform::work() @ 0x000000001699fca0 13. /build/src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x00000000169bd00f 14. /build/src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x00000000169b2105 15. /build/src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeSingleThread(unsigned long) @ 0x00000000169b23be 16. /build/src/Processors/Executors/PipelineExecutor.cpp:454: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x00000000169b0be7 17. /build/src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x00000000169b03f4 18. /build/src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:se190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169bfeab 19. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc3d92 20. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fcca080 21. ? @ 0x00007fbc6213eac3 22. ? @ 0x00007fbc621d0850 2025.07.28 11:57:42.474930 [ 17203 ] {} 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. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x000000000a06b56b 4. /build/src/Functions/throwIf.cpp:153: DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000e8193b5 5. /build/src/Functions/IFunctionAdaptors.cpp:10: DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000012d995fa 6. /build/src/Functions/IFunction.cpp:353: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d93b52 7. /build/src/Functions/IFunction.cpp:420: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d95059 8. /build/src/Functions/IFunction.cpp:498: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d95c72 9. /build/src/Interpreters/ExpressionActions.cpp:636: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x00000000145176f3 10. /build/src/Processors/Transforms/ExpressionTransform.cpp:25: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x0000000016c0b34c 11. /build/src/Processors/ISimpleTransform.h:33: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000011a9a453 12. /build/src/Processors/ISimpleTransform.cpp:89: DB::ISimpleTransform::work() @ 0x000000001699fca0 13. /build/src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x00000000169bd00f 14. /build/src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x00000000169b2105 15. /build/src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeSingleThread(unsigned long) @ 0x00000000169b23be 16. /build/src/Processors/Executors/PipelineExecutor.cpp:454: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x00000000169b0be7 17. /build/src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x00000000169b03f4 18. /build/src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:se190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169bfeab 19. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc3d92 20. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fcca080 21. ? @ 0x00007fbc6213eac3 22. ? @ 0x00007fbc621d0850 Job's origin stack trace: 0. /build/src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000000fc33b84 1. /build/src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000000fcc2ea7 2. /build/src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fcc535c 3. /build/src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000000fcc584d 4. /build/src/Common/ThreadPool.h:279: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x00000000169bf193 5. /build/src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x00000000169bf518 6. /build/src/Server/TCPHandler.cpp:1237: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x00000000168f1525 7. /build/src/Server/TCPHandler.cpp:678: DB::TCPHandler::runImpl() @ 0x00000000168e68e5 8. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 9. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 10. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 11. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 12. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 13. ? @ 0x00007fbc6213eac3 14. ? @ 0x00007fbc621d0850 2025.07.28 11:57:42.529768 [ 4581 ] {1260f838-10e6-4253-8415-cdf113113e2c} 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.6.10636.altinitytest (altinity build)) (from [::ffff:127.0.0.1]:39230) (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. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x000000000a06b56b 4. /build/src/Functions/throwIf.cpp:153: DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000e8193b5 5. /build/src/Functions/IFunctionAdaptors.cpp:10: DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000012d995fa 6. /build/src/Functions/IFunction.cpp:353: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d93b52 7. /build/src/Functions/IFunction.cpp:420: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d95059 8. /build/src/Functions/IFunction.cpp:498: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d95c72 9. /build/src/Interpreters/ExpressionActions.cpp:636: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x00000000145176f3 10. /build/src/Processors/Transforms/ExpressionTransform.cpp:25: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x0000000016c0b34c 11. /build/src/Processors/ISimpleTransform.h:33: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000011a9a453 12. /build/src/Processors/ISimpleTransform.cpp:89: DB::ISimpleTransform::work() @ 0x000000001699fca0 13. /build/src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x00000000169bd00f 14. /build/src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x00000000169b2105 15. /build/src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeSingleThread(unsigned long) @ 0x00000000169b23be 16. /build/src/Processors/Executors/PipelineExecutor.cpp:454: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x00000000169b0be7 17. /build/src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x00000000169b03f4 18. /build/src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:se190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169bfeab 19. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc3d92 20. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fcca080 21. ? @ 0x00007fbc6213eac3 22. ? @ 0x00007fbc621d0850 2025.07.28 11:57:42.533034 [ 4581 ] {1260f838-10e6-4253-8415-cdf113113e2c} 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]:39230). (NETWORK_ERROR), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::NetException::NetException(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&) @ 0x000000000fd50fb5 3. /build/src/IO/WriteBufferFromPocoSocket.cpp:171: DB::WriteBufferFromPocoSocket::nextImpl() @ 0x000000000fd525a7 4. /build/src/IO/WriteBuffer.h:53: DB::WriteBuffer::next() @ 0x000000000a0755be 5. /build/src/Server/TCPHandler.cpp:826: DB::TCPHandler::runImpl() @ 0x00000000168e6c9c 6. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 7. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 8. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 9. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 10. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 11. ? @ 0x00007fbc6213eac3 12. ? @ 0x00007fbc621d0850 (version 25.3.6.10636.altinitytest (altinity build)) 2025.07.28 11:57:42.535923 [ 4581 ] {} 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. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x000000000a06b56b 4. /build/src/Functions/throwIf.cpp:153: DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000e8193b5 5. /build/src/Functions/IFunctionAdaptors.cpp:10: DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000012d995fa 6. /build/src/Functions/IFunction.cpp:353: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d93b52 7. /build/src/Functions/IFunction.cpp:420: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d95059 8. /build/src/Functions/IFunction.cpp:498: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d95c72 9. /build/src/Interpreters/ExpressionActions.cpp:636: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x00000000145176f3 10. /build/src/Processors/Transforms/ExpressionTransform.cpp:25: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x0000000016c0b34c 11. /build/src/Processors/ISimpleTransform.h:33: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000011a9a453 12. /build/src/Processors/ISimpleTransform.cpp:89: DB::ISimpleTransform::work() @ 0x000000001699fca0 13. /build/src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x00000000169bd00f 14. /build/src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x00000000169b2105 15. /build/src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeSingleThread(unsigned long) @ 0x00000000169b23be 16. /build/src/Processors/Executors/PipelineExecutor.cpp:454: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x00000000169b0be7 17. /build/src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x00000000169b03f4 18. /build/src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:se190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169bfeab 19. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc3d92 20. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fcca080 21. ? @ 0x00007fbc6213eac3 22. ? @ 0x00007fbc621d0850 Job's origin stack trace: 0. /build/src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000000fc33b84 1. /build/src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000000fcc2ea7 2. /build/src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fcc535c 3. /build/src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000000fcc584d 4. /build/src/Common/ThreadPool.h:279: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x00000000169bf193 5. /build/src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x00000000169bf518 6. /build/src/Server/TCPHandler.cpp:1237: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x00000000168f1525 7. /build/src/Server/TCPHandler.cpp:678: DB::TCPHandler::runImpl() @ 0x00000000168e68e5 8. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 9. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 10. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 11. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 12. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 13. ? @ 0x00007fbc6213eac3 14. ? @ 0x00007fbc621d0850 2025.07.28 11:57:42.564297 [ 3967 ] {} test_13.rmt2 (7f9b740d-015c-470e-8cc6-8ba33be0dc63): auto DB::StorageReplicatedMergeTree::processQueueEntry(ReplicatedMergeTreeQueue::SelectedEntryPtr)::(anonymous class)::operator()(LogEntryPtr &) const: Code: 86. DB::HTTPException: Received error from remote server http://146b4357c08d:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Ftest%2F01165%2Ftest_13%2Frmt%2Freplicas%2F1&part=20250728_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.6.10636.altinitytest (altinity build)) '. (RECEIVED_ERROR_FROM_REMOTE_IO_SERVER), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.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 const&, int&&, String const&, unsigned long&&, String const&) @ 0x000000000feda8d9 4. /build/src/IO/HTTPCommon.cpp:104: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x000000000feda6e2 5. /build/src/IO/HTTPCommon.cpp:93: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x000000000feda537 6. /build/src/IO/ReadWriteBufferFromHTTP.cpp:277: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x000000001184a4c4 7. /build/src/IO/ReadWriteBufferFromHTTP.cpp:285: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x000000001184a615 8. /build/src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x000000001184ae59 9. /build/src/IO/ReadWriteBufferFromHTTP.cpp:472: void std::__function::__policy_invoker::__call_impl[abi:se190107]>(std::__function::__policy_storage const*) @ 0x000000001184cedd 10. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001184858b 11. /build/src/IO/ReadWriteBufferFromHTTP.cpp:465: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x000000001184bf0b 12. /build/src/IO/ReadBuffer.h:60: DB::ReadBuffer::next() @ 0x000000000a148c7b 13. /build/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) @ 0x0000000011849fb2 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]>&)>&, 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&) @ 0x0000000011841980 15. /build/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) @ 0x000000001621208e 16. /build/src/Storages/StorageReplicatedMergeTree.cpp:5228: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl[abi:se190107] const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000015f9a5fe 17. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000015ed8bfd 18. /build/src/Storages/StorageReplicatedMergeTree.cpp:2514: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x0000000015ec9aab 19. /build/src/Storages/StorageReplicatedMergeTree.cpp:2349: DB::StorageReplicatedMergeTree::executeLogEntry(DB::ReplicatedMergeTreeLogEntry&) @ 0x0000000015eba91b 20. /build/src/Storages/StorageReplicatedMergeTree.cpp:3876: bool std::__function::__policy_invoker&)>::__call_impl[abi:se190107])::$_1, bool (std::shared_ptr&)>>(std::__function::__policy_storage const*, std::shared_ptr&) @ 0x0000000015f9837e 21. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000165d6fc3 22. /build/src/Storages/StorageReplicatedMergeTree.cpp:3872: DB::StorageReplicatedMergeTree::processQueueEntry(std::shared_ptr) @ 0x0000000015efc18a 23. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001624c1b2 24. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000162f9c70 25. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x00000000162fa55a 26. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc6653 27. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000000fccc4c3 28. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc3d92 29. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fcca080 30. ? @ 0x00007fbc6213eac3 31. ? @ 0x00007fbc621d0850 (version 25.3.6.10636.altinitytest (altinity build)) 2025.07.28 11:57:42.701752 [ 4581 ] {80df1fd8-fc70-4d32-8e94-c5232bf41135} 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.6.10636.altinitytest (altinity build)) (from [::ffff:127.0.0.1]:34968) (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. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x000000000a06b56b 4. /build/src/Functions/throwIf.cpp:153: DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000e8193b5 5. /build/src/Functions/IFunctionAdaptors.cpp:10: DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000012d995fa 6. /build/src/Functions/IFunction.cpp:353: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d93b52 7. /build/src/Functions/IFunction.cpp:420: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d95059 8. /build/src/Functions/IFunction.cpp:498: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d95c72 9. /build/src/Interpreters/ExpressionActions.cpp:636: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x00000000145176f3 10. /build/src/Processors/Transforms/ExpressionTransform.cpp:25: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x0000000016c0b34c 11. /build/src/Processors/ISimpleTransform.h:33: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000011a9a453 12. /build/src/Processors/ISimpleTransform.cpp:89: DB::ISimpleTransform::work() @ 0x000000001699fca0 13. /build/src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x00000000169bd00f 14. /build/src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x00000000169b2105 15. /build/src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeSingleThread(unsigned long) @ 0x00000000169b23be 16. /build/src/Processors/Executors/PipelineExecutor.cpp:454: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x00000000169b0be7 17. /build/src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x00000000169b03f4 18. /build/src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:se190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169bfeab 19. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc3d92 20. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fcca080 21. ? @ 0x00007fbc6213eac3 22. ? @ 0x00007fbc621d0850 2025.07.28 11:57:42.717016 [ 4581 ] {} 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. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x000000000a06b56b 4. /build/src/Functions/throwIf.cpp:153: DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000e8193b5 5. /build/src/Functions/IFunctionAdaptors.cpp:10: DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000012d995fa 6. /build/src/Functions/IFunction.cpp:353: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d93b52 7. /build/src/Functions/IFunction.cpp:420: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d95059 8. /build/src/Functions/IFunction.cpp:498: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d95c72 9. /build/src/Interpreters/ExpressionActions.cpp:636: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x00000000145176f3 10. /build/src/Processors/Transforms/ExpressionTransform.cpp:25: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x0000000016c0b34c 11. /build/src/Processors/ISimpleTransform.h:33: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000011a9a453 12. /build/src/Processors/ISimpleTransform.cpp:89: DB::ISimpleTransform::work() @ 0x000000001699fca0 13. /build/src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x00000000169bd00f 14. /build/src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x00000000169b2105 15. /build/src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeSingleThread(unsigned long) @ 0x00000000169b23be 16. /build/src/Processors/Executors/PipelineExecutor.cpp:454: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x00000000169b0be7 17. /build/src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x00000000169b03f4 18. /build/src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:se190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169bfeab 19. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc3d92 20. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fcca080 21. ? @ 0x00007fbc6213eac3 22. ? @ 0x00007fbc621d0850 Job's origin stack trace: 0. /build/src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000000fc33b84 1. /build/src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000000fcc2ea7 2. /build/src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fcc535c 3. /build/src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000000fcc584d 4. /build/src/Common/ThreadPool.h:279: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x00000000169bf193 5. /build/src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x00000000169bf518 6. /build/src/Server/TCPHandler.cpp:1237: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x00000000168f1525 7. /build/src/Server/TCPHandler.cpp:678: DB::TCPHandler::runImpl() @ 0x00000000168e68e5 8. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 9. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 10. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 11. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 12. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 13. ? @ 0x00007fbc6213eac3 14. ? @ 0x00007fbc621d0850 2025.07.28 11:57:42.730493 [ 11851 ] {6f2bd142-404e-4ccc-ae94-fef8a0a72736} 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.6.10636.altinitytest (altinity build)) (from [::ffff:127.0.0.1]:39238) (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. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x000000000a06b56b 4. /build/src/Functions/throwIf.cpp:153: DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000e8193b5 5. /build/src/Functions/IFunctionAdaptors.cpp:10: DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000012d995fa 6. /build/src/Functions/IFunction.cpp:353: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d93b52 7. /build/src/Functions/IFunction.cpp:420: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d95059 8. /build/src/Functions/IFunction.cpp:498: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d95c72 9. /build/src/Interpreters/ExpressionActions.cpp:636: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x00000000145176f3 10. /build/src/Processors/Transforms/ExpressionTransform.cpp:25: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x0000000016c0b34c 11. /build/src/Processors/ISimpleTransform.h:33: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000011a9a453 12. /build/src/Processors/ISimpleTransform.cpp:89: DB::ISimpleTransform::work() @ 0x000000001699fca0 13. /build/src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x00000000169bd00f 14. /build/src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x00000000169b2105 15. /build/src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeSingleThread(unsigned long) @ 0x00000000169b23be 16. /build/src/Processors/Executors/PipelineExecutor.cpp:454: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x00000000169b0be7 17. /build/src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x00000000169b03f4 18. /build/src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:se190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169bfeab 19. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc3d92 20. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fcca080 21. ? @ 0x00007fbc6213eac3 22. ? @ 0x00007fbc621d0850 2025.07.28 11:57:42.766824 [ 11851 ] {} 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. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x000000000a06b56b 4. /build/src/Functions/throwIf.cpp:153: DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000e8193b5 5. /build/src/Functions/IFunctionAdaptors.cpp:10: DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000012d995fa 6. /build/src/Functions/IFunction.cpp:353: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d93b52 7. /build/src/Functions/IFunction.cpp:420: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d95059 8. /build/src/Functions/IFunction.cpp:498: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d95c72 9. /build/src/Interpreters/ExpressionActions.cpp:636: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x00000000145176f3 10. /build/src/Processors/Transforms/ExpressionTransform.cpp:25: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x0000000016c0b34c 11. /build/src/Processors/ISimpleTransform.h:33: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000011a9a453 12. /build/src/Processors/ISimpleTransform.cpp:89: DB::ISimpleTransform::work() @ 0x000000001699fca0 13. /build/src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x00000000169bd00f 14. /build/src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x00000000169b2105 15. /build/src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeSingleThread(unsigned long) @ 0x00000000169b23be 16. /build/src/Processors/Executors/PipelineExecutor.cpp:454: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x00000000169b0be7 17. /build/src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x00000000169b03f4 18. /build/src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:se190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169bfeab 19. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc3d92 20. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fcca080 21. ? @ 0x00007fbc6213eac3 22. ? @ 0x00007fbc621d0850 Job's origin stack trace: 0. /build/src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000000fc33b84 1. /build/src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000000fcc2ea7 2. /build/src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fcc535c 3. /build/src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000000fcc584d 4. /build/src/Common/ThreadPool.h:279: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x00000000169bf193 5. /build/src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x00000000169bf518 6. /build/src/Server/TCPHandler.cpp:1237: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x00000000168f1525 7. /build/src/Server/TCPHandler.cpp:678: DB::TCPHandler::runImpl() @ 0x00000000168e68e5 8. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 9. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 10. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 11. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 12. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 13. ? @ 0x00007fbc6213eac3 14. ? @ 0x00007fbc621d0850 2025.07.28 11:57:42.771801 [ 17203 ] {10ff593b-e125-4226-ac8a-958af6adb34b} 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. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x000000000a06b56b 4. /build/src/Functions/throwIf.cpp:153: DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000e8193b5 5. /build/src/Functions/IFunctionAdaptors.cpp:10: DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000012d995fa 6. /build/src/Functions/IFunction.cpp:353: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d93b52 7. /build/src/Functions/IFunction.cpp:420: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d95059 8. /build/src/Functions/IFunction.cpp:498: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d95c72 9. /build/src/Interpreters/ExpressionActions.cpp:636: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x00000000145176f3 10. /build/src/Processors/Transforms/ExpressionTransform.cpp:25: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x0000000016c0b34c 11. /build/src/Processors/ISimpleTransform.h:33: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000011a9a453 12. /build/src/Processors/ISimpleTransform.cpp:89: DB::ISimpleTransform::work() @ 0x000000001699fca0 13. /build/src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x00000000169bd00f 14. /build/src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x00000000169b2105 15. /build/src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeSingleThread(unsigned long) @ 0x00000000169b23be 16. /build/src/Processors/Executors/PipelineExecutor.cpp:454: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x00000000169b0be7 17. /build/src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x00000000169b03f4 18. /build/src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:se190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169bfeab 19. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc3d92 20. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fcca080 21. ? @ 0x00007fbc6213eac3 22. ? @ 0x00007fbc621d0850 Job's origin stack trace: 0. /build/src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000000fc33b84 1. /build/src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000000fcc2ea7 2. /build/src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fcc535c 3. /build/src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000000fcc584d 4. /build/src/Common/ThreadPool.h:279: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x00000000169bf193 5. /build/src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x00000000169bf518 6. /build/src/Server/TCPHandler.cpp:1237: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x00000000168f1525 7. /build/src/Server/TCPHandler.cpp:678: DB::TCPHandler::runImpl() @ 0x00000000168e68e5 8. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 9. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 10. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 11. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 12. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 13. ? @ 0x00007fbc6213eac3 14. ? @ 0x00007fbc621d0850 : While executing Remote. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO) (version 25.3.6.10636.altinitytest (altinity build)) (from [::1]:54186) (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. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:111: DB::readException(DB::ReadBuffer&, String const&, bool) @ 0x000000000fc6e157 3. /build/src/Client/Connection.cpp:1445: DB::Connection::receiveException() const @ 0x00000000167d4127 4. /build/src/Client/Connection.cpp:1274: DB::Connection::receivePacket() @ 0x00000000167db312 5. /build/src/Client/PacketReceiver.cpp:66: DB::PacketReceiver::Task::run(std::function, std::function) @ 0x0000000016819393 6. /build/src/Common/AsyncTaskExecutor.cpp:89: DB::AsyncTaskExecutor::Routine::operator()(std::function) @ 0x0000000013bd1892 7. /build/src/Common/Fiber.h:76: boost::context::detail::fiber_record>::run(void*) @ 0x0000000013bd16fa 8. /build/contrib/boost/boost/context/fiber_fcontext.hpp:97: void boost::context::detail::fiber_entry>>(boost::context::detail::transfer_t) @ 0x0000000013bd1621 2025.07.28 11:57:42.787691 [ 17203 ] {} 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. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x000000000a06b56b 4. /build/src/Functions/throwIf.cpp:153: DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000e8193b5 5. /build/src/Functions/IFunctionAdaptors.cpp:10: DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000012d995fa 6. /build/src/Functions/IFunction.cpp:353: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d93b52 7. /build/src/Functions/IFunction.cpp:420: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d95059 8. /build/src/Functions/IFunction.cpp:498: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d95c72 9. /build/src/Interpreters/ExpressionActions.cpp:636: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x00000000145176f3 10. /build/src/Processors/Transforms/ExpressionTransform.cpp:25: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x0000000016c0b34c 11. /build/src/Processors/ISimpleTransform.h:33: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000011a9a453 12. /build/src/Processors/ISimpleTransform.cpp:89: DB::ISimpleTransform::work() @ 0x000000001699fca0 13. /build/src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x00000000169bd00f 14. /build/src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x00000000169b2105 15. /build/src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeSingleThread(unsigned long) @ 0x00000000169b23be 16. /build/src/Processors/Executors/PipelineExecutor.cpp:454: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x00000000169b0be7 17. /build/src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x00000000169b03f4 18. /build/src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:se190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169bfeab 19. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc3d92 20. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fcca080 21. ? @ 0x00007fbc6213eac3 22. ? @ 0x00007fbc621d0850 Job's origin stack trace: 0. /build/src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000000fc33b84 1. /build/src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000000fcc2ea7 2. /build/src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fcc535c 3. /build/src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000000fcc584d 4. /build/src/Common/ThreadPool.h:279: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x00000000169bf193 5. /build/src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x00000000169bf518 6. /build/src/Server/TCPHandler.cpp:1237: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x00000000168f1525 7. /build/src/Server/TCPHandler.cpp:678: DB::TCPHandler::runImpl() @ 0x00000000168e68e5 8. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 9. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 10. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 11. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 12. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 13. ? @ 0x00007fbc6213eac3 14. ? @ 0x00007fbc621d0850 : While executing Remote. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:111: DB::readException(DB::ReadBuffer&, String const&, bool) @ 0x000000000fc6e157 3. /build/src/Client/Connection.cpp:1445: DB::Connection::receiveException() const @ 0x00000000167d4127 4. /build/src/Client/Connection.cpp:1274: DB::Connection::receivePacket() @ 0x00000000167db312 5. /build/src/Client/PacketReceiver.cpp:66: DB::PacketReceiver::Task::run(std::function, std::function) @ 0x0000000016819393 6. /build/src/Common/AsyncTaskExecutor.cpp:89: DB::AsyncTaskExecutor::Routine::operator()(std::function) @ 0x0000000013bd1892 7. /build/src/Common/Fiber.h:76: boost::context::detail::fiber_record>::run(void*) @ 0x0000000013bd16fa 8. /build/contrib/boost/boost/context/fiber_fcontext.hpp:97: void boost::context::detail::fiber_entry>>(boost::context::detail::transfer_t) @ 0x0000000013bd1621 Job's origin stack trace: 0. /build/src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000000fc33b84 1. /build/src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000000fcc2ea7 2. /build/src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fcc535c 3. /build/src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000000fcc584d 4. /build/src/Common/ThreadPool.h:279: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x00000000169bf193 5. /build/src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x00000000169bf518 6. /build/src/Server/TCPHandler.cpp:1237: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x00000000168f1525 7. /build/src/Server/TCPHandler.cpp:678: DB::TCPHandler::runImpl() @ 0x00000000168e68e5 8. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 9. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 10. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 11. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 12. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 13. ? @ 0x00007fbc6213eac3 14. ? @ 0x00007fbc621d0850 2025.07.28 11:57:43.126704 [ 3968 ] {} test_13.rmt2 (7f9b740d-015c-470e-8cc6-8ba33be0dc63): auto DB::StorageReplicatedMergeTree::processQueueEntry(ReplicatedMergeTreeQueue::SelectedEntryPtr)::(anonymous class)::operator()(LogEntryPtr &) const: Code: 86. DB::HTTPException: Received error from remote server http://146b4357c08d:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Ftest%2F01165%2Ftest_13%2Frmt%2Freplicas%2F1&part=20250728_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.6.10636.altinitytest (altinity build)) '. (RECEIVED_ERROR_FROM_REMOTE_IO_SERVER), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.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 const&, int&&, String const&, unsigned long&&, String const&) @ 0x000000000feda8d9 4. /build/src/IO/HTTPCommon.cpp:104: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x000000000feda6e2 5. /build/src/IO/HTTPCommon.cpp:93: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x000000000feda537 6. /build/src/IO/ReadWriteBufferFromHTTP.cpp:277: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x000000001184a4c4 7. /build/src/IO/ReadWriteBufferFromHTTP.cpp:285: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x000000001184a615 8. /build/src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x000000001184ae59 9. /build/src/IO/ReadWriteBufferFromHTTP.cpp:472: void std::__function::__policy_invoker::__call_impl[abi:se190107]>(std::__function::__policy_storage const*) @ 0x000000001184cedd 10. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001184858b 11. /build/src/IO/ReadWriteBufferFromHTTP.cpp:465: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x000000001184bf0b 12. /build/src/IO/ReadBuffer.h:60: DB::ReadBuffer::next() @ 0x000000000a148c7b 13. /build/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) @ 0x0000000011849fb2 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]>&)>&, 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&) @ 0x0000000011841980 15. /build/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) @ 0x000000001621208e 16. /build/src/Storages/StorageReplicatedMergeTree.cpp:5228: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl[abi:se190107] const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000015f9a5fe 17. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000015ed8bfd 18. /build/src/Storages/StorageReplicatedMergeTree.cpp:2514: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x0000000015ec9aab 19. /build/src/Storages/StorageReplicatedMergeTree.cpp:2349: DB::StorageReplicatedMergeTree::executeLogEntry(DB::ReplicatedMergeTreeLogEntry&) @ 0x0000000015eba91b 20. /build/src/Storages/StorageReplicatedMergeTree.cpp:3876: bool std::__function::__policy_invoker&)>::__call_impl[abi:se190107])::$_1, bool (std::shared_ptr&)>>(std::__function::__policy_storage const*, std::shared_ptr&) @ 0x0000000015f9837e 21. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000165d6fc3 22. /build/src/Storages/StorageReplicatedMergeTree.cpp:3872: DB::StorageReplicatedMergeTree::processQueueEntry(std::shared_ptr) @ 0x0000000015efc18a 23. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001624c1b2 24. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000162f9c70 25. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x00000000162fa55a 26. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc6653 27. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000000fccc4c3 28. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc3d92 29. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fcca080 30. ? @ 0x00007fbc6213eac3 31. ? @ 0x00007fbc621d0850 (version 25.3.6.10636.altinitytest (altinity build)) 2025.07.28 11:57:43.242136 [ 11851 ] {2b2db012-9e30-43e9-8b82-0e4c6c1c7ffa} 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.6.10636.altinitytest (altinity build)) (from [::ffff:127.0.0.1]:39244) (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. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x000000000a06b56b 4. /build/src/Functions/throwIf.cpp:153: DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000e8193b5 5. /build/src/Functions/IFunctionAdaptors.cpp:10: DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000012d995fa 6. /build/src/Functions/IFunction.cpp:353: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d93b52 7. /build/src/Functions/IFunction.cpp:420: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d95059 8. /build/src/Functions/IFunction.cpp:498: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d95c72 9. /build/src/Interpreters/ExpressionActions.cpp:636: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x00000000145176f3 10. /build/src/Processors/Transforms/ExpressionTransform.cpp:25: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x0000000016c0b34c 11. /build/src/Processors/ISimpleTransform.h:33: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000011a9a453 12. /build/src/Processors/ISimpleTransform.cpp:89: DB::ISimpleTransform::work() @ 0x000000001699fca0 13. /build/src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x00000000169bd00f 14. /build/src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x00000000169b2105 15. /build/src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeSingleThread(unsigned long) @ 0x00000000169b23be 16. /build/src/Processors/Executors/PipelineExecutor.cpp:454: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x00000000169b0be7 17. /build/src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x00000000169b03f4 18. /build/src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:se190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169bfeab 19. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc3d92 20. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fcca080 21. ? @ 0x00007fbc6213eac3 22. ? @ 0x00007fbc621d0850 2025.07.28 11:57:43.252312 [ 11851 ] {} 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. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x000000000a06b56b 4. /build/src/Functions/throwIf.cpp:153: DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000e8193b5 5. /build/src/Functions/IFunctionAdaptors.cpp:10: DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000012d995fa 6. /build/src/Functions/IFunction.cpp:353: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d93b52 7. /build/src/Functions/IFunction.cpp:420: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d95059 8. /build/src/Functions/IFunction.cpp:498: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d95c72 9. /build/src/Interpreters/ExpressionActions.cpp:636: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x00000000145176f3 10. /build/src/Processors/Transforms/ExpressionTransform.cpp:25: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x0000000016c0b34c 11. /build/src/Processors/ISimpleTransform.h:33: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000011a9a453 12. /build/src/Processors/ISimpleTransform.cpp:89: DB::ISimpleTransform::work() @ 0x000000001699fca0 13. /build/src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x00000000169bd00f 14. /build/src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x00000000169b2105 15. /build/src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeSingleThread(unsigned long) @ 0x00000000169b23be 16. /build/src/Processors/Executors/PipelineExecutor.cpp:454: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x00000000169b0be7 17. /build/src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x00000000169b03f4 18. /build/src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:se190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169bfeab 19. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc3d92 20. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fcca080 21. ? @ 0x00007fbc6213eac3 22. ? @ 0x00007fbc621d0850 Job's origin stack trace: 0. /build/src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000000fc33b84 1. /build/src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000000fcc2ea7 2. /build/src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fcc535c 3. /build/src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000000fcc584d 4. /build/src/Common/ThreadPool.h:279: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x00000000169bf193 5. /build/src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x00000000169bf518 6. /build/src/Server/TCPHandler.cpp:1237: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x00000000168f1525 7. /build/src/Server/TCPHandler.cpp:678: DB::TCPHandler::runImpl() @ 0x00000000168e68e5 8. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 9. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 10. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 11. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 12. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 13. ? @ 0x00007fbc6213eac3 14. ? @ 0x00007fbc621d0850 2025.07.28 11:57:43.260320 [ 17255 ] {f7bbdd36-2cdb-4beb-88f0-2e819baeec8a} 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.6.10636.altinitytest (altinity build)) (from [::ffff:127.0.0.1]:34984) (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. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x000000000a06b56b 4. /build/src/Functions/throwIf.cpp:153: DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000e8193b5 5. /build/src/Functions/IFunctionAdaptors.cpp:10: DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000012d995fa 6. /build/src/Functions/IFunction.cpp:353: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d93b52 7. /build/src/Functions/IFunction.cpp:420: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d95059 8. /build/src/Functions/IFunction.cpp:498: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d95c72 9. /build/src/Interpreters/ExpressionActions.cpp:636: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x00000000145176f3 10. /build/src/Processors/Transforms/ExpressionTransform.cpp:25: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x0000000016c0b34c 11. /build/src/Processors/ISimpleTransform.h:33: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000011a9a453 12. /build/src/Processors/ISimpleTransform.cpp:89: DB::ISimpleTransform::work() @ 0x000000001699fca0 13. /build/src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x00000000169bd00f 14. /build/src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x00000000169b2105 15. /build/src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeSingleThread(unsigned long) @ 0x00000000169b23be 16. /build/src/Processors/Executors/PipelineExecutor.cpp:454: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x00000000169b0be7 17. /build/src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x00000000169b03f4 18. /build/src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:se190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169bfeab 19. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc3d92 20. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fcca080 21. ? @ 0x00007fbc6213eac3 22. ? @ 0x00007fbc621d0850 2025.07.28 11:57:43.290401 [ 17255 ] {} 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. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x000000000a06b56b 4. /build/src/Functions/throwIf.cpp:153: DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000e8193b5 5. /build/src/Functions/IFunctionAdaptors.cpp:10: DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000012d995fa 6. /build/src/Functions/IFunction.cpp:353: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d93b52 7. /build/src/Functions/IFunction.cpp:420: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d95059 8. /build/src/Functions/IFunction.cpp:498: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d95c72 9. /build/src/Interpreters/ExpressionActions.cpp:636: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x00000000145176f3 10. /build/src/Processors/Transforms/ExpressionTransform.cpp:25: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x0000000016c0b34c 11. /build/src/Processors/ISimpleTransform.h:33: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000011a9a453 12. /build/src/Processors/ISimpleTransform.cpp:89: DB::ISimpleTransform::work() @ 0x000000001699fca0 13. /build/src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x00000000169bd00f 14. /build/src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x00000000169b2105 15. /build/src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeSingleThread(unsigned long) @ 0x00000000169b23be 16. /build/src/Processors/Executors/PipelineExecutor.cpp:454: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x00000000169b0be7 17. /build/src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x00000000169b03f4 18. /build/src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:se190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169bfeab 19. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc3d92 20. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fcca080 21. ? @ 0x00007fbc6213eac3 22. ? @ 0x00007fbc621d0850 Job's origin stack trace: 0. /build/src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000000fc33b84 1. /build/src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000000fcc2ea7 2. /build/src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fcc535c 3. /build/src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000000fcc584d 4. /build/src/Common/ThreadPool.h:279: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x00000000169bf193 5. /build/src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x00000000169bf518 6. /build/src/Server/TCPHandler.cpp:1237: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x00000000168f1525 7. /build/src/Server/TCPHandler.cpp:678: DB::TCPHandler::runImpl() @ 0x00000000168e68e5 8. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 9. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 10. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 11. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 12. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 13. ? @ 0x00007fbc6213eac3 14. ? @ 0x00007fbc621d0850 2025.07.28 11:57:43.301549 [ 17203 ] {8c05756c-62af-4299-974d-cf7656f50307} 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. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x000000000a06b56b 4. /build/src/Functions/throwIf.cpp:153: DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000e8193b5 5. /build/src/Functions/IFunctionAdaptors.cpp:10: DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000012d995fa 6. /build/src/Functions/IFunction.cpp:353: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d93b52 7. /build/src/Functions/IFunction.cpp:420: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d95059 8. /build/src/Functions/IFunction.cpp:498: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d95c72 9. /build/src/Interpreters/ExpressionActions.cpp:636: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x00000000145176f3 10. /build/src/Processors/Transforms/ExpressionTransform.cpp:25: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x0000000016c0b34c 11. /build/src/Processors/ISimpleTransform.h:33: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000011a9a453 12. /build/src/Processors/ISimpleTransform.cpp:89: DB::ISimpleTransform::work() @ 0x000000001699fca0 13. /build/src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x00000000169bd00f 14. /build/src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x00000000169b2105 15. /build/src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeSingleThread(unsigned long) @ 0x00000000169b23be 16. /build/src/Processors/Executors/PipelineExecutor.cpp:454: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x00000000169b0be7 17. /build/src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x00000000169b03f4 18. /build/src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:se190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169bfeab 19. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc3d92 20. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fcca080 21. ? @ 0x00007fbc6213eac3 22. ? @ 0x00007fbc621d0850 Job's origin stack trace: 0. /build/src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000000fc33b84 1. /build/src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000000fcc2ea7 2. /build/src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fcc535c 3. /build/src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000000fcc584d 4. /build/src/Common/ThreadPool.h:279: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x00000000169bf193 5. /build/src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x00000000169bf518 6. /build/src/Server/TCPHandler.cpp:1237: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x00000000168f1525 7. /build/src/Server/TCPHandler.cpp:678: DB::TCPHandler::runImpl() @ 0x00000000168e68e5 8. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 9. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 10. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 11. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 12. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 13. ? @ 0x00007fbc6213eac3 14. ? @ 0x00007fbc621d0850 : While executing Remote. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO) (version 25.3.6.10636.altinitytest (altinity build)) (from [::1]:54186) (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. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:111: DB::readException(DB::ReadBuffer&, String const&, bool) @ 0x000000000fc6e157 3. /build/src/Client/Connection.cpp:1445: DB::Connection::receiveException() const @ 0x00000000167d4127 4. /build/src/Client/Connection.cpp:1274: DB::Connection::receivePacket() @ 0x00000000167db312 5. /build/src/Client/PacketReceiver.cpp:66: DB::PacketReceiver::Task::run(std::function, std::function) @ 0x0000000016819393 6. /build/src/Common/AsyncTaskExecutor.cpp:89: DB::AsyncTaskExecutor::Routine::operator()(std::function) @ 0x0000000013bd1892 7. /build/src/Common/Fiber.h:76: boost::context::detail::fiber_record>::run(void*) @ 0x0000000013bd16fa 8. /build/contrib/boost/boost/context/fiber_fcontext.hpp:97: void boost::context::detail::fiber_entry>>(boost::context::detail::transfer_t) @ 0x0000000013bd1621 2025.07.28 11:57:43.349414 [ 17203 ] {} 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. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x000000000a06b56b 4. /build/src/Functions/throwIf.cpp:153: DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000e8193b5 5. /build/src/Functions/IFunctionAdaptors.cpp:10: DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000012d995fa 6. /build/src/Functions/IFunction.cpp:353: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d93b52 7. /build/src/Functions/IFunction.cpp:420: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d95059 8. /build/src/Functions/IFunction.cpp:498: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d95c72 9. /build/src/Interpreters/ExpressionActions.cpp:636: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x00000000145176f3 10. /build/src/Processors/Transforms/ExpressionTransform.cpp:25: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x0000000016c0b34c 11. /build/src/Processors/ISimpleTransform.h:33: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000011a9a453 12. /build/src/Processors/ISimpleTransform.cpp:89: DB::ISimpleTransform::work() @ 0x000000001699fca0 13. /build/src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x00000000169bd00f 14. /build/src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x00000000169b2105 15. /build/src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeSingleThread(unsigned long) @ 0x00000000169b23be 16. /build/src/Processors/Executors/PipelineExecutor.cpp:454: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x00000000169b0be7 17. /build/src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x00000000169b03f4 18. /build/src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:se190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169bfeab 19. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc3d92 20. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fcca080 21. ? @ 0x00007fbc6213eac3 22. ? @ 0x00007fbc621d0850 Job's origin stack trace: 0. /build/src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000000fc33b84 1. /build/src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000000fcc2ea7 2. /build/src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fcc535c 3. /build/src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000000fcc584d 4. /build/src/Common/ThreadPool.h:279: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x00000000169bf193 5. /build/src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x00000000169bf518 6. /build/src/Server/TCPHandler.cpp:1237: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x00000000168f1525 7. /build/src/Server/TCPHandler.cpp:678: DB::TCPHandler::runImpl() @ 0x00000000168e68e5 8. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 9. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 10. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 11. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 12. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 13. ? @ 0x00007fbc6213eac3 14. ? @ 0x00007fbc621d0850 : While executing Remote. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:111: DB::readException(DB::ReadBuffer&, String const&, bool) @ 0x000000000fc6e157 3. /build/src/Client/Connection.cpp:1445: DB::Connection::receiveException() const @ 0x00000000167d4127 4. /build/src/Client/Connection.cpp:1274: DB::Connection::receivePacket() @ 0x00000000167db312 5. /build/src/Client/PacketReceiver.cpp:66: DB::PacketReceiver::Task::run(std::function, std::function) @ 0x0000000016819393 6. /build/src/Common/AsyncTaskExecutor.cpp:89: DB::AsyncTaskExecutor::Routine::operator()(std::function) @ 0x0000000013bd1892 7. /build/src/Common/Fiber.h:76: boost::context::detail::fiber_record>::run(void*) @ 0x0000000013bd16fa 8. /build/contrib/boost/boost/context/fiber_fcontext.hpp:97: void boost::context::detail::fiber_entry>>(boost::context::detail::transfer_t) @ 0x0000000013bd1621 Job's origin stack trace: 0. /build/src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000000fc33b84 1. /build/src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000000fcc2ea7 2. /build/src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fcc535c 3. /build/src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000000fcc584d 4. /build/src/Common/ThreadPool.h:279: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x00000000169bf193 5. /build/src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x00000000169bf518 6. /build/src/Server/TCPHandler.cpp:1237: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x00000000168f1525 7. /build/src/Server/TCPHandler.cpp:678: DB::TCPHandler::runImpl() @ 0x00000000168e68e5 8. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 9. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 10. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 11. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 12. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 13. ? @ 0x00007fbc6213eac3 14. ? @ 0x00007fbc621d0850 2025.07.28 11:57:43.679286 [ 4900 ] {10e37874-30b7-4b9f-8d74-333e89bf47c4} 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.6.10636.altinitytest (altinity build)) (from [::ffff:127.0.0.1]:35000) (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. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x000000000a06b56b 4. /build/src/Functions/throwIf.cpp:153: DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000e8193b5 5. /build/src/Functions/IFunctionAdaptors.cpp:10: DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000012d995fa 6. /build/src/Functions/IFunction.cpp:353: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d93b52 7. /build/src/Functions/IFunction.cpp:420: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d95059 8. /build/src/Functions/IFunction.cpp:498: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d95c72 9. /build/src/Interpreters/ExpressionActions.cpp:636: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x00000000145176f3 10. /build/src/Processors/Transforms/ExpressionTransform.cpp:25: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x0000000016c0b34c 11. /build/src/Processors/ISimpleTransform.h:33: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000011a9a453 12. /build/src/Processors/ISimpleTransform.cpp:89: DB::ISimpleTransform::work() @ 0x000000001699fca0 13. /build/src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x00000000169bd00f 14. /build/src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x00000000169b2105 15. /build/src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeSingleThread(unsigned long) @ 0x00000000169b23be 16. /build/src/Processors/Executors/PipelineExecutor.cpp:454: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x00000000169b0be7 17. /build/src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x00000000169b03f4 18. /build/src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:se190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169bfeab 19. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc3d92 20. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fcca080 21. ? @ 0x00007fbc6213eac3 22. ? @ 0x00007fbc621d0850 2025.07.28 11:57:43.684994 [ 4900 ] {} 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. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x000000000a06b56b 4. /build/src/Functions/throwIf.cpp:153: DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000e8193b5 5. /build/src/Functions/IFunctionAdaptors.cpp:10: DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000012d995fa 6. /build/src/Functions/IFunction.cpp:353: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d93b52 7. /build/src/Functions/IFunction.cpp:420: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d95059 8. /build/src/Functions/IFunction.cpp:498: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d95c72 9. /build/src/Interpreters/ExpressionActions.cpp:636: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x00000000145176f3 10. /build/src/Processors/Transforms/ExpressionTransform.cpp:25: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x0000000016c0b34c 11. /build/src/Processors/ISimpleTransform.h:33: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000011a9a453 12. /build/src/Processors/ISimpleTransform.cpp:89: DB::ISimpleTransform::work() @ 0x000000001699fca0 13. /build/src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x00000000169bd00f 14. /build/src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x00000000169b2105 15. /build/src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeSingleThread(unsigned long) @ 0x00000000169b23be 16. /build/src/Processors/Executors/PipelineExecutor.cpp:454: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x00000000169b0be7 17. /build/src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x00000000169b03f4 18. /build/src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:se190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169bfeab 19. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc3d92 20. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fcca080 21. ? @ 0x00007fbc6213eac3 22. ? @ 0x00007fbc621d0850 Job's origin stack trace: 0. /build/src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000000fc33b84 1. /build/src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000000fcc2ea7 2. /build/src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fcc535c 3. /build/src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000000fcc584d 4. /build/src/Common/ThreadPool.h:279: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x00000000169bf193 5. /build/src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x00000000169bf518 6. /build/src/Server/TCPHandler.cpp:1237: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x00000000168f1525 7. /build/src/Server/TCPHandler.cpp:678: DB::TCPHandler::runImpl() @ 0x00000000168e68e5 8. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 9. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 10. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 11. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 12. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 13. ? @ 0x00007fbc6213eac3 14. ? @ 0x00007fbc621d0850 2025.07.28 11:57:43.685702 [ 17255 ] {d4f447ea-408f-4012-8ad2-157e97247c04} 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.6.10636.altinitytest (altinity build)) (from [::ffff:127.0.0.1]:39246) (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. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x000000000a06b56b 4. /build/src/Functions/throwIf.cpp:153: DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000e8193b5 5. /build/src/Functions/IFunctionAdaptors.cpp:10: DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000012d995fa 6. /build/src/Functions/IFunction.cpp:353: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d93b52 7. /build/src/Functions/IFunction.cpp:420: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d95059 8. /build/src/Functions/IFunction.cpp:498: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d95c72 9. /build/src/Interpreters/ExpressionActions.cpp:636: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x00000000145176f3 10. /build/src/Processors/Transforms/ExpressionTransform.cpp:25: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x0000000016c0b34c 11. /build/src/Processors/ISimpleTransform.h:33: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000011a9a453 12. /build/src/Processors/ISimpleTransform.cpp:89: DB::ISimpleTransform::work() @ 0x000000001699fca0 13. /build/src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x00000000169bd00f 14. /build/src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x00000000169b2105 15. /build/src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeSingleThread(unsigned long) @ 0x00000000169b23be 16. /build/src/Processors/Executors/PipelineExecutor.cpp:454: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x00000000169b0be7 17. /build/src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x00000000169b03f4 18. /build/src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:se190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169bfeab 19. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc3d92 20. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fcca080 21. ? @ 0x00007fbc6213eac3 22. ? @ 0x00007fbc621d0850 2025.07.28 11:57:43.700856 [ 17255 ] {} 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. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x000000000a06b56b 4. /build/src/Functions/throwIf.cpp:153: DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000e8193b5 5. /build/src/Functions/IFunctionAdaptors.cpp:10: DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000012d995fa 6. /build/src/Functions/IFunction.cpp:353: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d93b52 7. /build/src/Functions/IFunction.cpp:420: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d95059 8. /build/src/Functions/IFunction.cpp:498: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d95c72 9. /build/src/Interpreters/ExpressionActions.cpp:636: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x00000000145176f3 10. /build/src/Processors/Transforms/ExpressionTransform.cpp:25: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x0000000016c0b34c 11. /build/src/Processors/ISimpleTransform.h:33: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000011a9a453 12. /build/src/Processors/ISimpleTransform.cpp:89: DB::ISimpleTransform::work() @ 0x000000001699fca0 13. /build/src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x00000000169bd00f 14. /build/src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x00000000169b2105 15. /build/src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeSingleThread(unsigned long) @ 0x00000000169b23be 16. /build/src/Processors/Executors/PipelineExecutor.cpp:454: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x00000000169b0be7 17. /build/src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x00000000169b03f4 18. /build/src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:se190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169bfeab 19. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc3d92 20. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fcca080 21. ? @ 0x00007fbc6213eac3 22. ? @ 0x00007fbc621d0850 Job's origin stack trace: 0. /build/src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000000fc33b84 1. /build/src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000000fcc2ea7 2. /build/src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fcc535c 3. /build/src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000000fcc584d 4. /build/src/Common/ThreadPool.h:279: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x00000000169bf193 5. /build/src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x00000000169bf518 6. /build/src/Server/TCPHandler.cpp:1237: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x00000000168f1525 7. /build/src/Server/TCPHandler.cpp:678: DB::TCPHandler::runImpl() @ 0x00000000168e68e5 8. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 9. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 10. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 11. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 12. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 13. ? @ 0x00007fbc6213eac3 14. ? @ 0x00007fbc621d0850 2025.07.28 11:57:43.705414 [ 17203 ] {2f84f4e2-84bc-4561-b888-9408e34da73f} 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. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x000000000a06b56b 4. /build/src/Functions/throwIf.cpp:153: DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000e8193b5 5. /build/src/Functions/IFunctionAdaptors.cpp:10: DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000012d995fa 6. /build/src/Functions/IFunction.cpp:353: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d93b52 7. /build/src/Functions/IFunction.cpp:420: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d95059 8. /build/src/Functions/IFunction.cpp:498: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d95c72 9. /build/src/Interpreters/ExpressionActions.cpp:636: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x00000000145176f3 10. /build/src/Processors/Transforms/ExpressionTransform.cpp:25: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x0000000016c0b34c 11. /build/src/Processors/ISimpleTransform.h:33: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000011a9a453 12. /build/src/Processors/ISimpleTransform.cpp:89: DB::ISimpleTransform::work() @ 0x000000001699fca0 13. /build/src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x00000000169bd00f 14. /build/src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x00000000169b2105 15. /build/src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeSingleThread(unsigned long) @ 0x00000000169b23be 16. /build/src/Processors/Executors/PipelineExecutor.cpp:454: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x00000000169b0be7 17. /build/src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x00000000169b03f4 18. /build/src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:se190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169bfeab 19. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc3d92 20. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fcca080 21. ? @ 0x00007fbc6213eac3 22. ? @ 0x00007fbc621d0850 Job's origin stack trace: 0. /build/src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000000fc33b84 1. /build/src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000000fcc2ea7 2. /build/src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fcc535c 3. /build/src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000000fcc584d 4. /build/src/Common/ThreadPool.h:279: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x00000000169bf193 5. /build/src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x00000000169bf518 6. /build/src/Server/TCPHandler.cpp:1237: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x00000000168f1525 7. /build/src/Server/TCPHandler.cpp:678: DB::TCPHandler::runImpl() @ 0x00000000168e68e5 8. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 9. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 10. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 11. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 12. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 13. ? @ 0x00007fbc6213eac3 14. ? @ 0x00007fbc621d0850 : While executing Remote. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO) (version 25.3.6.10636.altinitytest (altinity build)) (from [::1]:54186) (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. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:111: DB::readException(DB::ReadBuffer&, String const&, bool) @ 0x000000000fc6e157 3. /build/src/Client/Connection.cpp:1445: DB::Connection::receiveException() const @ 0x00000000167d4127 4. /build/src/Client/Connection.cpp:1274: DB::Connection::receivePacket() @ 0x00000000167db312 5. /build/src/Client/PacketReceiver.cpp:66: DB::PacketReceiver::Task::run(std::function, std::function) @ 0x0000000016819393 6. /build/src/Common/AsyncTaskExecutor.cpp:89: DB::AsyncTaskExecutor::Routine::operator()(std::function) @ 0x0000000013bd1892 7. /build/src/Common/Fiber.h:76: boost::context::detail::fiber_record>::run(void*) @ 0x0000000013bd16fa 8. /build/contrib/boost/boost/context/fiber_fcontext.hpp:97: void boost::context::detail::fiber_entry>>(boost::context::detail::transfer_t) @ 0x0000000013bd1621 2025.07.28 11:57:43.722713 [ 17203 ] {} 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. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x000000000a06b56b 4. /build/src/Functions/throwIf.cpp:153: DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000e8193b5 5. /build/src/Functions/IFunctionAdaptors.cpp:10: DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000012d995fa 6. /build/src/Functions/IFunction.cpp:353: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d93b52 7. /build/src/Functions/IFunction.cpp:420: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d95059 8. /build/src/Functions/IFunction.cpp:498: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d95c72 9. /build/src/Interpreters/ExpressionActions.cpp:636: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x00000000145176f3 10. /build/src/Processors/Transforms/ExpressionTransform.cpp:25: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x0000000016c0b34c 11. /build/src/Processors/ISimpleTransform.h:33: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000011a9a453 12. /build/src/Processors/ISimpleTransform.cpp:89: DB::ISimpleTransform::work() @ 0x000000001699fca0 13. /build/src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x00000000169bd00f 14. /build/src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x00000000169b2105 15. /build/src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeSingleThread(unsigned long) @ 0x00000000169b23be 16. /build/src/Processors/Executors/PipelineExecutor.cpp:454: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x00000000169b0be7 17. /build/src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x00000000169b03f4 18. /build/src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:se190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169bfeab 19. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc3d92 20. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fcca080 21. ? @ 0x00007fbc6213eac3 22. ? @ 0x00007fbc621d0850 Job's origin stack trace: 0. /build/src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000000fc33b84 1. /build/src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000000fcc2ea7 2. /build/src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fcc535c 3. /build/src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000000fcc584d 4. /build/src/Common/ThreadPool.h:279: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x00000000169bf193 5. /build/src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x00000000169bf518 6. /build/src/Server/TCPHandler.cpp:1237: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x00000000168f1525 7. /build/src/Server/TCPHandler.cpp:678: DB::TCPHandler::runImpl() @ 0x00000000168e68e5 8. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 9. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 10. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 11. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 12. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 13. ? @ 0x00007fbc6213eac3 14. ? @ 0x00007fbc621d0850 : While executing Remote. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:111: DB::readException(DB::ReadBuffer&, String const&, bool) @ 0x000000000fc6e157 3. /build/src/Client/Connection.cpp:1445: DB::Connection::receiveException() const @ 0x00000000167d4127 4. /build/src/Client/Connection.cpp:1274: DB::Connection::receivePacket() @ 0x00000000167db312 5. /build/src/Client/PacketReceiver.cpp:66: DB::PacketReceiver::Task::run(std::function, std::function) @ 0x0000000016819393 6. /build/src/Common/AsyncTaskExecutor.cpp:89: DB::AsyncTaskExecutor::Routine::operator()(std::function) @ 0x0000000013bd1892 7. /build/src/Common/Fiber.h:76: boost::context::detail::fiber_record>::run(void*) @ 0x0000000013bd16fa 8. /build/contrib/boost/boost/context/fiber_fcontext.hpp:97: void boost::context::detail::fiber_entry>>(boost::context::detail::transfer_t) @ 0x0000000013bd1621 Job's origin stack trace: 0. /build/src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000000fc33b84 1. /build/src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000000fcc2ea7 2. /build/src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fcc535c 3. /build/src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000000fcc584d 4. /build/src/Common/ThreadPool.h:279: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x00000000169bf193 5. /build/src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x00000000169bf518 6. /build/src/Server/TCPHandler.cpp:1237: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x00000000168f1525 7. /build/src/Server/TCPHandler.cpp:678: DB::TCPHandler::runImpl() @ 0x00000000168e68e5 8. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 9. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 10. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 11. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 12. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 13. ? @ 0x00007fbc6213eac3 14. ? @ 0x00007fbc621d0850 2025.07.28 11:57:43.745353 [ 3965 ] {} test_13.rmt2 (7f9b740d-015c-470e-8cc6-8ba33be0dc63): auto DB::StorageReplicatedMergeTree::processQueueEntry(ReplicatedMergeTreeQueue::SelectedEntryPtr)::(anonymous class)::operator()(LogEntryPtr &) const: Code: 86. DB::HTTPException: Received error from remote server http://146b4357c08d:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Ftest%2F01165%2Ftest_13%2Frmt%2Freplicas%2F1&part=20250728_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.6.10636.altinitytest (altinity build)) '. (RECEIVED_ERROR_FROM_REMOTE_IO_SERVER), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.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 const&, int&&, String const&, unsigned long&&, String const&) @ 0x000000000feda8d9 4. /build/src/IO/HTTPCommon.cpp:104: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x000000000feda6e2 5. /build/src/IO/HTTPCommon.cpp:93: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x000000000feda537 6. /build/src/IO/ReadWriteBufferFromHTTP.cpp:277: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x000000001184a4c4 7. /build/src/IO/ReadWriteBufferFromHTTP.cpp:285: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x000000001184a615 8. /build/src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x000000001184ae59 9. /build/src/IO/ReadWriteBufferFromHTTP.cpp:472: void std::__function::__policy_invoker::__call_impl[abi:se190107]>(std::__function::__policy_storage const*) @ 0x000000001184cedd 10. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001184858b 11. /build/src/IO/ReadWriteBufferFromHTTP.cpp:465: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x000000001184bf0b 12. /build/src/IO/ReadBuffer.h:60: DB::ReadBuffer::next() @ 0x000000000a148c7b 13. /build/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) @ 0x0000000011849fb2 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]>&)>&, 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&) @ 0x0000000011841980 15. /build/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) @ 0x000000001621208e 16. /build/src/Storages/StorageReplicatedMergeTree.cpp:5228: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl[abi:se190107] const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000015f9a5fe 17. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000015ed8bfd 18. /build/src/Storages/StorageReplicatedMergeTree.cpp:2514: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x0000000015ec9aab 19. /build/src/Storages/StorageReplicatedMergeTree.cpp:2349: DB::StorageReplicatedMergeTree::executeLogEntry(DB::ReplicatedMergeTreeLogEntry&) @ 0x0000000015eba91b 20. /build/src/Storages/StorageReplicatedMergeTree.cpp:3876: bool std::__function::__policy_invoker&)>::__call_impl[abi:se190107])::$_1, bool (std::shared_ptr&)>>(std::__function::__policy_storage const*, std::shared_ptr&) @ 0x0000000015f9837e 21. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000165d6fc3 22. /build/src/Storages/StorageReplicatedMergeTree.cpp:3872: DB::StorageReplicatedMergeTree::processQueueEntry(std::shared_ptr) @ 0x0000000015efc18a 23. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001624c1b2 24. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000162f9c70 25. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x00000000162fa55a 26. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc6653 27. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000000fccc4c3 28. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc3d92 29. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fcca080 30. ? @ 0x00007fbc6213eac3 31. ? @ 0x00007fbc621d0850 (version 25.3.6.10636.altinitytest (altinity build)) 2025.07.28 11:57:44.135402 [ 3962 ] {} test_13.rmt2 (7f9b740d-015c-470e-8cc6-8ba33be0dc63): auto DB::StorageReplicatedMergeTree::processQueueEntry(ReplicatedMergeTreeQueue::SelectedEntryPtr)::(anonymous class)::operator()(LogEntryPtr &) const: Code: 86. DB::HTTPException: Received error from remote server http://146b4357c08d:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Ftest%2F01165%2Ftest_13%2Frmt%2Freplicas%2F1&part=20250728_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.6.10636.altinitytest (altinity build)) '. (RECEIVED_ERROR_FROM_REMOTE_IO_SERVER), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.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 const&, int&&, String const&, unsigned long&&, String const&) @ 0x000000000feda8d9 4. /build/src/IO/HTTPCommon.cpp:104: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x000000000feda6e2 5. /build/src/IO/HTTPCommon.cpp:93: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x000000000feda537 6. /build/src/IO/ReadWriteBufferFromHTTP.cpp:277: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x000000001184a4c4 7. /build/src/IO/ReadWriteBufferFromHTTP.cpp:285: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x000000001184a615 8. /build/src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x000000001184ae59 9. /build/src/IO/ReadWriteBufferFromHTTP.cpp:472: void std::__function::__policy_invoker::__call_impl[abi:se190107]>(std::__function::__policy_storage const*) @ 0x000000001184cedd 10. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001184858b 11. /build/src/IO/ReadWriteBufferFromHTTP.cpp:465: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x000000001184bf0b 12. /build/src/IO/ReadBuffer.h:60: DB::ReadBuffer::next() @ 0x000000000a148c7b 13. /build/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) @ 0x0000000011849fb2 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]>&)>&, 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&) @ 0x0000000011841980 15. /build/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) @ 0x000000001621208e 16. /build/src/Storages/StorageReplicatedMergeTree.cpp:5228: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl[abi:se190107] const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000015f9a5fe 17. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000015ed8bfd 18. /build/src/Storages/StorageReplicatedMergeTree.cpp:2514: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x0000000015ec9aab 19. /build/src/Storages/StorageReplicatedMergeTree.cpp:2349: DB::StorageReplicatedMergeTree::executeLogEntry(DB::ReplicatedMergeTreeLogEntry&) @ 0x0000000015eba91b 20. /build/src/Storages/StorageReplicatedMergeTree.cpp:3876: bool std::__function::__policy_invoker&)>::__call_impl[abi:se190107])::$_1, bool (std::shared_ptr&)>>(std::__function::__policy_storage const*, std::shared_ptr&) @ 0x0000000015f9837e 21. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000165d6fc3 22. /build/src/Storages/StorageReplicatedMergeTree.cpp:3872: DB::StorageReplicatedMergeTree::processQueueEntry(std::shared_ptr) @ 0x0000000015efc18a 23. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001624c1b2 24. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000162f9c70 25. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x00000000162fa55a 26. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc6653 27. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000000fccc4c3 28. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc3d92 29. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fcca080 30. ? @ 0x00007fbc6213eac3 31. ? @ 0x00007fbc621d0850 (version 25.3.6.10636.altinitytest (altinity build)) 2025.07.28 11:57:44.833392 [ 3977 ] {} test_13.rmt2 (7f9b740d-015c-470e-8cc6-8ba33be0dc63): auto DB::StorageReplicatedMergeTree::processQueueEntry(ReplicatedMergeTreeQueue::SelectedEntryPtr)::(anonymous class)::operator()(LogEntryPtr &) const: Code: 86. DB::HTTPException: Received error from remote server http://146b4357c08d:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Ftest%2F01165%2Ftest_13%2Frmt%2Freplicas%2F1&part=20250728_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.6.10636.altinitytest (altinity build)) '. (RECEIVED_ERROR_FROM_REMOTE_IO_SERVER), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.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 const&, int&&, String const&, unsigned long&&, String const&) @ 0x000000000feda8d9 4. /build/src/IO/HTTPCommon.cpp:104: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x000000000feda6e2 5. /build/src/IO/HTTPCommon.cpp:93: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x000000000feda537 6. /build/src/IO/ReadWriteBufferFromHTTP.cpp:277: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x000000001184a4c4 7. /build/src/IO/ReadWriteBufferFromHTTP.cpp:285: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x000000001184a615 8. /build/src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x000000001184ae59 9. /build/src/IO/ReadWriteBufferFromHTTP.cpp:472: void std::__function::__policy_invoker::__call_impl[abi:se190107]>(std::__function::__policy_storage const*) @ 0x000000001184cedd 10. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001184858b 11. /build/src/IO/ReadWriteBufferFromHTTP.cpp:465: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x000000001184bf0b 12. /build/src/IO/ReadBuffer.h:60: DB::ReadBuffer::next() @ 0x000000000a148c7b 13. /build/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) @ 0x0000000011849fb2 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]>&)>&, 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&) @ 0x0000000011841980 15. /build/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) @ 0x000000001621208e 16. /build/src/Storages/StorageReplicatedMergeTree.cpp:5228: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl[abi:se190107] const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000015f9a5fe 17. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000015ed8bfd 18. /build/src/Storages/StorageReplicatedMergeTree.cpp:2514: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x0000000015ec9aab 19. /build/src/Storages/StorageReplicatedMergeTree.cpp:2349: DB::StorageReplicatedMergeTree::executeLogEntry(DB::ReplicatedMergeTreeLogEntry&) @ 0x0000000015eba91b 20. /build/src/Storages/StorageReplicatedMergeTree.cpp:3876: bool std::__function::__policy_invoker&)>::__call_impl[abi:se190107])::$_1, bool (std::shared_ptr&)>>(std::__function::__policy_storage const*, std::shared_ptr&) @ 0x0000000015f9837e 21. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000165d6fc3 22. /build/src/Storages/StorageReplicatedMergeTree.cpp:3872: DB::StorageReplicatedMergeTree::processQueueEntry(std::shared_ptr) @ 0x0000000015efc18a 23. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001624c1b2 24. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000162f9c70 25. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x00000000162fa55a 26. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc6653 27. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000000fccc4c3 28. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc3d92 29. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fcca080 30. ? @ 0x00007fbc6213eac3 31. ? @ 0x00007fbc621d0850 (version 25.3.6.10636.altinitytest (altinity build)) 2025.07.28 11:57:45.108428 [ 3970 ] {} test_13.rmt2 (7f9b740d-015c-470e-8cc6-8ba33be0dc63): auto DB::StorageReplicatedMergeTree::processQueueEntry(ReplicatedMergeTreeQueue::SelectedEntryPtr)::(anonymous class)::operator()(LogEntryPtr &) const: Code: 86. DB::HTTPException: Received error from remote server http://146b4357c08d:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Ftest%2F01165%2Ftest_13%2Frmt%2Freplicas%2F1&part=20250728_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.6.10636.altinitytest (altinity build)) '. (RECEIVED_ERROR_FROM_REMOTE_IO_SERVER), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.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 const&, int&&, String const&, unsigned long&&, String const&) @ 0x000000000feda8d9 4. /build/src/IO/HTTPCommon.cpp:104: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x000000000feda6e2 5. /build/src/IO/HTTPCommon.cpp:93: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x000000000feda537 6. /build/src/IO/ReadWriteBufferFromHTTP.cpp:277: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x000000001184a4c4 7. /build/src/IO/ReadWriteBufferFromHTTP.cpp:285: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x000000001184a615 8. /build/src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x000000001184ae59 9. /build/src/IO/ReadWriteBufferFromHTTP.cpp:472: void std::__function::__policy_invoker::__call_impl[abi:se190107]>(std::__function::__policy_storage const*) @ 0x000000001184cedd 10. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001184858b 11. /build/src/IO/ReadWriteBufferFromHTTP.cpp:465: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x000000001184bf0b 12. /build/src/IO/ReadBuffer.h:60: DB::ReadBuffer::next() @ 0x000000000a148c7b 13. /build/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) @ 0x0000000011849fb2 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]>&)>&, 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&) @ 0x0000000011841980 15. /build/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) @ 0x000000001621208e 16. /build/src/Storages/StorageReplicatedMergeTree.cpp:5228: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl[abi:se190107] const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000015f9a5fe 17. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000015ed8bfd 18. /build/src/Storages/StorageReplicatedMergeTree.cpp:2514: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x0000000015ec9aab 19. /build/src/Storages/StorageReplicatedMergeTree.cpp:2349: DB::StorageReplicatedMergeTree::executeLogEntry(DB::ReplicatedMergeTreeLogEntry&) @ 0x0000000015eba91b 20. /build/src/Storages/StorageReplicatedMergeTree.cpp:3876: bool std::__function::__policy_invoker&)>::__call_impl[abi:se190107])::$_1, bool (std::shared_ptr&)>>(std::__function::__policy_storage const*, std::shared_ptr&) @ 0x0000000015f9837e 21. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000165d6fc3 22. /build/src/Storages/StorageReplicatedMergeTree.cpp:3872: DB::StorageReplicatedMergeTree::processQueueEntry(std::shared_ptr) @ 0x0000000015efc18a 23. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001624c1b2 24. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000162f9c70 25. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x00000000162fa55a 26. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc6653 27. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000000fccc4c3 28. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc3d92 29. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fcca080 30. ? @ 0x00007fbc6213eac3 31. ? @ 0x00007fbc621d0850 (version 25.3.6.10636.altinitytest (altinity build)) 2025.07.28 11:57:45.340126 [ 3969 ] {} test_13.rmt2 (7f9b740d-015c-470e-8cc6-8ba33be0dc63): auto DB::StorageReplicatedMergeTree::processQueueEntry(ReplicatedMergeTreeQueue::SelectedEntryPtr)::(anonymous class)::operator()(LogEntryPtr &) const: Code: 86. DB::HTTPException: Received error from remote server http://146b4357c08d:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Ftest%2F01165%2Ftest_13%2Frmt%2Freplicas%2F1&part=20250728_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.6.10636.altinitytest (altinity build)) '. (RECEIVED_ERROR_FROM_REMOTE_IO_SERVER), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.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 const&, int&&, String const&, unsigned long&&, String const&) @ 0x000000000feda8d9 4. /build/src/IO/HTTPCommon.cpp:104: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x000000000feda6e2 5. /build/src/IO/HTTPCommon.cpp:93: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x000000000feda537 6. /build/src/IO/ReadWriteBufferFromHTTP.cpp:277: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x000000001184a4c4 7. /build/src/IO/ReadWriteBufferFromHTTP.cpp:285: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x000000001184a615 8. /build/src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x000000001184ae59 9. /build/src/IO/ReadWriteBufferFromHTTP.cpp:472: void std::__function::__policy_invoker::__call_impl[abi:se190107]>(std::__function::__policy_storage const*) @ 0x000000001184cedd 10. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001184858b 11. /build/src/IO/ReadWriteBufferFromHTTP.cpp:465: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x000000001184bf0b 12. /build/src/IO/ReadBuffer.h:60: DB::ReadBuffer::next() @ 0x000000000a148c7b 13. /build/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) @ 0x0000000011849fb2 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]>&)>&, 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&) @ 0x0000000011841980 15. /build/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) @ 0x000000001621208e 16. /build/src/Storages/StorageReplicatedMergeTree.cpp:5228: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl[abi:se190107] const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000015f9a5fe 17. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000015ed8bfd 18. /build/src/Storages/StorageReplicatedMergeTree.cpp:2514: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x0000000015ec9aab 19. /build/src/Storages/StorageReplicatedMergeTree.cpp:2349: DB::StorageReplicatedMergeTree::executeLogEntry(DB::ReplicatedMergeTreeLogEntry&) @ 0x0000000015eba91b 20. /build/src/Storages/StorageReplicatedMergeTree.cpp:3876: bool std::__function::__policy_invoker&)>::__call_impl[abi:se190107])::$_1, bool (std::shared_ptr&)>>(std::__function::__policy_storage const*, std::shared_ptr&) @ 0x0000000015f9837e 21. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000165d6fc3 22. /build/src/Storages/StorageReplicatedMergeTree.cpp:3872: DB::StorageReplicatedMergeTree::processQueueEntry(std::shared_ptr) @ 0x0000000015efc18a 23. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001624c1b2 24. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000162f9c70 25. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x00000000162fa55a 26. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc6653 27. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000000fccc4c3 28. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc3d92 29. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fcca080 30. ? @ 0x00007fbc6213eac3 31. ? @ 0x00007fbc621d0850 (version 25.3.6.10636.altinitytest (altinity build)) 2025.07.28 11:57:45.651782 [ 3971 ] {} test_13.rmt2 (7f9b740d-015c-470e-8cc6-8ba33be0dc63): auto DB::StorageReplicatedMergeTree::processQueueEntry(ReplicatedMergeTreeQueue::SelectedEntryPtr)::(anonymous class)::operator()(LogEntryPtr &) const: Code: 86. DB::HTTPException: Received error from remote server http://146b4357c08d:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Ftest%2F01165%2Ftest_13%2Frmt%2Freplicas%2F1&part=20250728_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.6.10636.altinitytest (altinity build)) '. (RECEIVED_ERROR_FROM_REMOTE_IO_SERVER), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.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 const&, int&&, String const&, unsigned long&&, String const&) @ 0x000000000feda8d9 4. /build/src/IO/HTTPCommon.cpp:104: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x000000000feda6e2 5. /build/src/IO/HTTPCommon.cpp:93: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x000000000feda537 6. /build/src/IO/ReadWriteBufferFromHTTP.cpp:277: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x000000001184a4c4 7. /build/src/IO/ReadWriteBufferFromHTTP.cpp:285: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x000000001184a615 8. /build/src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x000000001184ae59 9. /build/src/IO/ReadWriteBufferFromHTTP.cpp:472: void std::__function::__policy_invoker::__call_impl[abi:se190107]>(std::__function::__policy_storage const*) @ 0x000000001184cedd 10. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001184858b 11. /build/src/IO/ReadWriteBufferFromHTTP.cpp:465: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x000000001184bf0b 12. /build/src/IO/ReadBuffer.h:60: DB::ReadBuffer::next() @ 0x000000000a148c7b 13. /build/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) @ 0x0000000011849fb2 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]>&)>&, 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&) @ 0x0000000011841980 15. /build/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) @ 0x000000001621208e 16. /build/src/Storages/StorageReplicatedMergeTree.cpp:5228: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl[abi:se190107] const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000015f9a5fe 17. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000015ed8bfd 18. /build/src/Storages/StorageReplicatedMergeTree.cpp:2514: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x0000000015ec9aab 19. /build/src/Storages/StorageReplicatedMergeTree.cpp:2349: DB::StorageReplicatedMergeTree::executeLogEntry(DB::ReplicatedMergeTreeLogEntry&) @ 0x0000000015eba91b 20. /build/src/Storages/StorageReplicatedMergeTree.cpp:3876: bool std::__function::__policy_invoker&)>::__call_impl[abi:se190107])::$_1, bool (std::shared_ptr&)>>(std::__function::__policy_storage const*, std::shared_ptr&) @ 0x0000000015f9837e 21. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000165d6fc3 22. /build/src/Storages/StorageReplicatedMergeTree.cpp:3872: DB::StorageReplicatedMergeTree::processQueueEntry(std::shared_ptr) @ 0x0000000015efc18a 23. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001624c1b2 24. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000162f9c70 25. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x00000000162fa55a 26. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc6653 27. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000000fccc4c3 28. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc3d92 29. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fcca080 30. ? @ 0x00007fbc6213eac3 31. ? @ 0x00007fbc621d0850 (version 25.3.6.10636.altinitytest (altinity build)) 2025.07.28 11:57:46.254504 [ 3977 ] {} test_13.rmt2 (7f9b740d-015c-470e-8cc6-8ba33be0dc63): auto DB::StorageReplicatedMergeTree::processQueueEntry(ReplicatedMergeTreeQueue::SelectedEntryPtr)::(anonymous class)::operator()(LogEntryPtr &) const: Code: 86. DB::HTTPException: Received error from remote server http://146b4357c08d:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Ftest%2F01165%2Ftest_13%2Frmt%2Freplicas%2F1&part=20250728_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.6.10636.altinitytest (altinity build)) '. (RECEIVED_ERROR_FROM_REMOTE_IO_SERVER), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.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 const&, int&&, String const&, unsigned long&&, String const&) @ 0x000000000feda8d9 4. /build/src/IO/HTTPCommon.cpp:104: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x000000000feda6e2 5. /build/src/IO/HTTPCommon.cpp:93: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x000000000feda537 6. /build/src/IO/ReadWriteBufferFromHTTP.cpp:277: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x000000001184a4c4 7. /build/src/IO/ReadWriteBufferFromHTTP.cpp:285: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x000000001184a615 8. /build/src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x000000001184ae59 9. /build/src/IO/ReadWriteBufferFromHTTP.cpp:472: void std::__function::__policy_invoker::__call_impl[abi:se190107]>(std::__function::__policy_storage const*) @ 0x000000001184cedd 10. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001184858b 11. /build/src/IO/ReadWriteBufferFromHTTP.cpp:465: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x000000001184bf0b 12. /build/src/IO/ReadBuffer.h:60: DB::ReadBuffer::next() @ 0x000000000a148c7b 13. /build/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) @ 0x0000000011849fb2 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]>&)>&, 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&) @ 0x0000000011841980 15. /build/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) @ 0x000000001621208e 16. /build/src/Storages/StorageReplicatedMergeTree.cpp:5228: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl[abi:se190107] const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000015f9a5fe 17. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000015ed8bfd 18. /build/src/Storages/StorageReplicatedMergeTree.cpp:2514: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x0000000015ec9aab 19. /build/src/Storages/StorageReplicatedMergeTree.cpp:2349: DB::StorageReplicatedMergeTree::executeLogEntry(DB::ReplicatedMergeTreeLogEntry&) @ 0x0000000015eba91b 20. /build/src/Storages/StorageReplicatedMergeTree.cpp:3876: bool std::__function::__policy_invoker&)>::__call_impl[abi:se190107])::$_1, bool (std::shared_ptr&)>>(std::__function::__policy_storage const*, std::shared_ptr&) @ 0x0000000015f9837e 21. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000165d6fc3 22. /build/src/Storages/StorageReplicatedMergeTree.cpp:3872: DB::StorageReplicatedMergeTree::processQueueEntry(std::shared_ptr) @ 0x0000000015efc18a 23. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001624c1b2 24. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000162f9c70 25. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x00000000162fa55a 26. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc6653 27. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000000fccc4c3 28. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc3d92 29. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fcca080 30. ? @ 0x00007fbc6213eac3 31. ? @ 0x00007fbc621d0850 (version 25.3.6.10636.altinitytest (altinity build)) 2025.07.28 11:57:46.884352 [ 3965 ] {} test_13.rmt2 (7f9b740d-015c-470e-8cc6-8ba33be0dc63): auto DB::StorageReplicatedMergeTree::processQueueEntry(ReplicatedMergeTreeQueue::SelectedEntryPtr)::(anonymous class)::operator()(LogEntryPtr &) const: Code: 86. DB::HTTPException: Received error from remote server http://146b4357c08d:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Ftest%2F01165%2Ftest_13%2Frmt%2Freplicas%2F1&part=20250728_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.6.10636.altinitytest (altinity build)) '. (RECEIVED_ERROR_FROM_REMOTE_IO_SERVER), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.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 const&, int&&, String const&, unsigned long&&, String const&) @ 0x000000000feda8d9 4. /build/src/IO/HTTPCommon.cpp:104: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x000000000feda6e2 5. /build/src/IO/HTTPCommon.cpp:93: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x000000000feda537 6. /build/src/IO/ReadWriteBufferFromHTTP.cpp:277: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x000000001184a4c4 7. /build/src/IO/ReadWriteBufferFromHTTP.cpp:285: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x000000001184a615 8. /build/src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x000000001184ae59 9. /build/src/IO/ReadWriteBufferFromHTTP.cpp:472: void std::__function::__policy_invoker::__call_impl[abi:se190107]>(std::__function::__policy_storage const*) @ 0x000000001184cedd 10. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001184858b 11. /build/src/IO/ReadWriteBufferFromHTTP.cpp:465: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x000000001184bf0b 12. /build/src/IO/ReadBuffer.h:60: DB::ReadBuffer::next() @ 0x000000000a148c7b 13. /build/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) @ 0x0000000011849fb2 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]>&)>&, 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&) @ 0x0000000011841980 15. /build/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) @ 0x000000001621208e 16. /build/src/Storages/StorageReplicatedMergeTree.cpp:5228: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl[abi:se190107] const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000015f9a5fe 17. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000015ed8bfd 18. /build/src/Storages/StorageReplicatedMergeTree.cpp:2514: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x0000000015ec9aab 19. /build/src/Storages/StorageReplicatedMergeTree.cpp:2349: DB::StorageReplicatedMergeTree::executeLogEntry(DB::ReplicatedMergeTreeLogEntry&) @ 0x0000000015eba91b 20. /build/src/Storages/StorageReplicatedMergeTree.cpp:3876: bool std::__function::__policy_invoker&)>::__call_impl[abi:se190107])::$_1, bool (std::shared_ptr&)>>(std::__function::__policy_storage const*, std::shared_ptr&) @ 0x0000000015f9837e 21. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000165d6fc3 22. /build/src/Storages/StorageReplicatedMergeTree.cpp:3872: DB::StorageReplicatedMergeTree::processQueueEntry(std::shared_ptr) @ 0x0000000015efc18a 23. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001624c1b2 24. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000162f9c70 25. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x00000000162fa55a 26. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc6653 27. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000000fccc4c3 28. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc3d92 29. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fcca080 30. ? @ 0x00007fbc6213eac3 31. ? @ 0x00007fbc621d0850 (version 25.3.6.10636.altinitytest (altinity build)) 2025.07.28 11:57:47.227649 [ 3963 ] {} test_13.rmt2 (7f9b740d-015c-470e-8cc6-8ba33be0dc63): auto DB::StorageReplicatedMergeTree::processQueueEntry(ReplicatedMergeTreeQueue::SelectedEntryPtr)::(anonymous class)::operator()(LogEntryPtr &) const: Code: 86. DB::HTTPException: Received error from remote server http://146b4357c08d:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Ftest%2F01165%2Ftest_13%2Frmt%2Freplicas%2F1&part=20250728_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.6.10636.altinitytest (altinity build)) '. (RECEIVED_ERROR_FROM_REMOTE_IO_SERVER), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.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 const&, int&&, String const&, unsigned long&&, String const&) @ 0x000000000feda8d9 4. /build/src/IO/HTTPCommon.cpp:104: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x000000000feda6e2 5. /build/src/IO/HTTPCommon.cpp:93: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x000000000feda537 6. /build/src/IO/ReadWriteBufferFromHTTP.cpp:277: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x000000001184a4c4 7. /build/src/IO/ReadWriteBufferFromHTTP.cpp:285: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x000000001184a615 8. /build/src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x000000001184ae59 9. /build/src/IO/ReadWriteBufferFromHTTP.cpp:472: void std::__function::__policy_invoker::__call_impl[abi:se190107]>(std::__function::__policy_storage const*) @ 0x000000001184cedd 10. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001184858b 11. /build/src/IO/ReadWriteBufferFromHTTP.cpp:465: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x000000001184bf0b 12. /build/src/IO/ReadBuffer.h:60: DB::ReadBuffer::next() @ 0x000000000a148c7b 13. /build/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) @ 0x0000000011849fb2 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]>&)>&, 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&) @ 0x0000000011841980 15. /build/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) @ 0x000000001621208e 16. /build/src/Storages/StorageReplicatedMergeTree.cpp:5228: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl[abi:se190107] const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000015f9a5fe 17. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000015ed8bfd 18. /build/src/Storages/StorageReplicatedMergeTree.cpp:2514: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x0000000015ec9aab 19. /build/src/Storages/StorageReplicatedMergeTree.cpp:2349: DB::StorageReplicatedMergeTree::executeLogEntry(DB::ReplicatedMergeTreeLogEntry&) @ 0x0000000015eba91b 20. /build/src/Storages/StorageReplicatedMergeTree.cpp:3876: bool std::__function::__policy_invoker&)>::__call_impl[abi:se190107])::$_1, bool (std::shared_ptr&)>>(std::__function::__policy_storage const*, std::shared_ptr&) @ 0x0000000015f9837e 21. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000165d6fc3 22. /build/src/Storages/StorageReplicatedMergeTree.cpp:3872: DB::StorageReplicatedMergeTree::processQueueEntry(std::shared_ptr) @ 0x0000000015efc18a 23. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001624c1b2 24. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000162f9c70 25. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x00000000162fa55a 26. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc6653 27. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000000fccc4c3 28. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc3d92 29. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fcca080 30. ? @ 0x00007fbc6213eac3 31. ? @ 0x00007fbc621d0850 (version 25.3.6.10636.altinitytest (altinity build)) 2025.07.28 11:57:48.032685 [ 3961 ] {} test_13.rmt2 (7f9b740d-015c-470e-8cc6-8ba33be0dc63): auto DB::StorageReplicatedMergeTree::processQueueEntry(ReplicatedMergeTreeQueue::SelectedEntryPtr)::(anonymous class)::operator()(LogEntryPtr &) const: Code: 86. DB::HTTPException: Received error from remote server http://146b4357c08d:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Ftest%2F01165%2Ftest_13%2Frmt%2Freplicas%2F1&part=20250728_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.6.10636.altinitytest (altinity build)) '. (RECEIVED_ERROR_FROM_REMOTE_IO_SERVER), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.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 const&, int&&, String const&, unsigned long&&, String const&) @ 0x000000000feda8d9 4. /build/src/IO/HTTPCommon.cpp:104: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x000000000feda6e2 5. /build/src/IO/HTTPCommon.cpp:93: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x000000000feda537 6. /build/src/IO/ReadWriteBufferFromHTTP.cpp:277: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x000000001184a4c4 7. /build/src/IO/ReadWriteBufferFromHTTP.cpp:285: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x000000001184a615 8. /build/src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x000000001184ae59 9. /build/src/IO/ReadWriteBufferFromHTTP.cpp:472: void std::__function::__policy_invoker::__call_impl[abi:se190107]>(std::__function::__policy_storage const*) @ 0x000000001184cedd 10. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001184858b 11. /build/src/IO/ReadWriteBufferFromHTTP.cpp:465: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x000000001184bf0b 12. /build/src/IO/ReadBuffer.h:60: DB::ReadBuffer::next() @ 0x000000000a148c7b 13. /build/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) @ 0x0000000011849fb2 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]>&)>&, 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&) @ 0x0000000011841980 15. /build/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) @ 0x000000001621208e 16. /build/src/Storages/StorageReplicatedMergeTree.cpp:5228: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl[abi:se190107] const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000015f9a5fe 17. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000015ed8bfd 18. /build/src/Storages/StorageReplicatedMergeTree.cpp:2514: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x0000000015ec9aab 19. /build/src/Storages/StorageReplicatedMergeTree.cpp:2349: DB::StorageReplicatedMergeTree::executeLogEntry(DB::ReplicatedMergeTreeLogEntry&) @ 0x0000000015eba91b 20. /build/src/Storages/StorageReplicatedMergeTree.cpp:3876: bool std::__function::__policy_invoker&)>::__call_impl[abi:se190107])::$_1, bool (std::shared_ptr&)>>(std::__function::__policy_storage const*, std::shared_ptr&) @ 0x0000000015f9837e 21. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000165d6fc3 22. /build/src/Storages/StorageReplicatedMergeTree.cpp:3872: DB::StorageReplicatedMergeTree::processQueueEntry(std::shared_ptr) @ 0x0000000015efc18a 23. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001624c1b2 24. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000162f9c70 25. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x00000000162fa55a 26. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc6653 27. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000000fccc4c3 28. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc3d92 29. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fcca080 30. ? @ 0x00007fbc6213eac3 31. ? @ 0x00007fbc621d0850 (version 25.3.6.10636.altinitytest (altinity build)) 2025.07.28 11:57:48.111103 [ 17255 ] {3ff94860-1d24-4f8a-bbcb-12bfde34c6d8} executeQuery: Code: 57. DB::Exception: Table test_15.t2 already exists. (TABLE_ALREADY_EXISTS) (version 25.3.6.10636.altinitytest (altinity build)) (from [::1]:54546) (comment: 02000_join_on_const.sql) (query 4, line 5) (in query: CREATE TABLE t2 (`id` Int) ENGINE = MergeTree ORDER BY tuple() SETTINGS index_granularity = 25362, min_bytes_for_wide_part = 0, 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 = 412284255, compact_parts_max_granules_to_buffer = 1, compact_parts_merge_max_bytes_to_prefetch_part = 14948124, merge_max_block_size = 21252, old_parts_lifetime = 439., prefer_fetch_merged_part_size_threshold = 7372161681, vertical_merge_algorithm_min_rows_to_activate = 1, vertical_merge_algorithm_min_columns_to_activate = 20, min_merge_bytes_to_use_direct_io = 8701359998, index_granularity_bytes = 13082239, use_const_adaptive_granularity = true, enable_index_granularity_compression = false, concurrent_part_removal_threshold = 69, allow_vertical_merges_from_compact_to_wide_parts = false, enable_block_number_column = false, enable_block_offset_column = true, cache_populated_by_fetch = true, marks_compress_block_size = 78827, primary_key_compress_block_size = 16151, 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. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000a06a8eb 4. /build/src/Interpreters/InterpreterCreateQuery.cpp:1824: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x0000000014901d53 5. /build/src/Interpreters/InterpreterCreateQuery.cpp:1743: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000148f9aa9 6. /build/src/Interpreters/InterpreterCreateQuery.cpp:2352: DB::InterpreterCreateQuery::execute() @ 0x0000000014905a41 7. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88dc9 8. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 9. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 10. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 11. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 12. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 13. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 14. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 15. ? @ 0x00007fbc6213eac3 16. ? @ 0x00007fbc621d0850 2025.07.28 11:57:48.118165 [ 17255 ] {} TCPHandler: Code: 57. DB::Exception: Table test_15.t2 already exists. (TABLE_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000a06a8eb 4. /build/src/Interpreters/InterpreterCreateQuery.cpp:1824: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x0000000014901d53 5. /build/src/Interpreters/InterpreterCreateQuery.cpp:1743: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000148f9aa9 6. /build/src/Interpreters/InterpreterCreateQuery.cpp:2352: DB::InterpreterCreateQuery::execute() @ 0x0000000014905a41 7. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88dc9 8. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 9. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 10. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 11. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 12. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 13. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 14. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 15. ? @ 0x00007fbc6213eac3 16. ? @ 0x00007fbc621d0850 2025.07.28 11:57:48.516137 [ 5112 ] {} TCPHandler: Code: 394. DB::Exception: Query 'b1e64305-1de9-43d2-bb41-873396f4c63b' is killed in pending state. (QUERY_WAS_CANCELLED), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x000000000a06b56b 4. /build/src/Interpreters/executeQuery.cpp:1522: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c8a4ef 5. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 6. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 7. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 8. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 9. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 10. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 11. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 12. ? @ 0x00007fbc6213eac3 13. ? @ 0x00007fbc621d0850 2025.07.28 11:57:48.954763 [ 3974 ] {} test_13.rmt2 (7f9b740d-015c-470e-8cc6-8ba33be0dc63): auto DB::StorageReplicatedMergeTree::processQueueEntry(ReplicatedMergeTreeQueue::SelectedEntryPtr)::(anonymous class)::operator()(LogEntryPtr &) const: Code: 86. DB::HTTPException: Received error from remote server http://146b4357c08d:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Ftest%2F01165%2Ftest_13%2Frmt%2Freplicas%2F1&part=20250728_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.6.10636.altinitytest (altinity build)) '. (RECEIVED_ERROR_FROM_REMOTE_IO_SERVER), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.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 const&, int&&, String const&, unsigned long&&, String const&) @ 0x000000000feda8d9 4. /build/src/IO/HTTPCommon.cpp:104: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x000000000feda6e2 5. /build/src/IO/HTTPCommon.cpp:93: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x000000000feda537 6. /build/src/IO/ReadWriteBufferFromHTTP.cpp:277: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x000000001184a4c4 7. /build/src/IO/ReadWriteBufferFromHTTP.cpp:285: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x000000001184a615 8. /build/src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x000000001184ae59 9. /build/src/IO/ReadWriteBufferFromHTTP.cpp:472: void std::__function::__policy_invoker::__call_impl[abi:se190107]>(std::__function::__policy_storage const*) @ 0x000000001184cedd 10. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001184858b 11. /build/src/IO/ReadWriteBufferFromHTTP.cpp:465: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x000000001184bf0b 12. /build/src/IO/ReadBuffer.h:60: DB::ReadBuffer::next() @ 0x000000000a148c7b 13. /build/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) @ 0x0000000011849fb2 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]>&)>&, 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&) @ 0x0000000011841980 15. /build/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) @ 0x000000001621208e 16. /build/src/Storages/StorageReplicatedMergeTree.cpp:5228: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl[abi:se190107] const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000015f9a5fe 17. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000015ed8bfd 18. /build/src/Storages/StorageReplicatedMergeTree.cpp:2514: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x0000000015ec9aab 19. /build/src/Storages/StorageReplicatedMergeTree.cpp:2349: DB::StorageReplicatedMergeTree::executeLogEntry(DB::ReplicatedMergeTreeLogEntry&) @ 0x0000000015eba91b 20. /build/src/Storages/StorageReplicatedMergeTree.cpp:3876: bool std::__function::__policy_invoker&)>::__call_impl[abi:se190107])::$_1, bool (std::shared_ptr&)>>(std::__function::__policy_storage const*, std::shared_ptr&) @ 0x0000000015f9837e 21. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000165d6fc3 22. /build/src/Storages/StorageReplicatedMergeTree.cpp:3872: DB::StorageReplicatedMergeTree::processQueueEntry(std::shared_ptr) @ 0x0000000015efc18a 23. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001624c1b2 24. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000162f9c70 25. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x00000000162fa55a 26. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc6653 27. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000000fccc4c3 28. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc3d92 29. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fcca080 30. ? @ 0x00007fbc6213eac3 31. ? @ 0x00007fbc621d0850 (version 25.3.6.10636.altinitytest (altinity build)) 2025.07.28 11:57:49.320998 [ 3969 ] {} test_13.rmt2 (7f9b740d-015c-470e-8cc6-8ba33be0dc63): auto DB::StorageReplicatedMergeTree::processQueueEntry(ReplicatedMergeTreeQueue::SelectedEntryPtr)::(anonymous class)::operator()(LogEntryPtr &) const: Code: 86. DB::HTTPException: Received error from remote server http://146b4357c08d:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Ftest%2F01165%2Ftest_13%2Frmt%2Freplicas%2F1&part=20250728_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.6.10636.altinitytest (altinity build)) '. (RECEIVED_ERROR_FROM_REMOTE_IO_SERVER), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.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 const&, int&&, String const&, unsigned long&&, String const&) @ 0x000000000feda8d9 4. /build/src/IO/HTTPCommon.cpp:104: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x000000000feda6e2 5. /build/src/IO/HTTPCommon.cpp:93: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x000000000feda537 6. /build/src/IO/ReadWriteBufferFromHTTP.cpp:277: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x000000001184a4c4 7. /build/src/IO/ReadWriteBufferFromHTTP.cpp:285: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x000000001184a615 8. /build/src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x000000001184ae59 9. /build/src/IO/ReadWriteBufferFromHTTP.cpp:472: void std::__function::__policy_invoker::__call_impl[abi:se190107]>(std::__function::__policy_storage const*) @ 0x000000001184cedd 10. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001184858b 11. /build/src/IO/ReadWriteBufferFromHTTP.cpp:465: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x000000001184bf0b 12. /build/src/IO/ReadBuffer.h:60: DB::ReadBuffer::next() @ 0x000000000a148c7b 13. /build/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) @ 0x0000000011849fb2 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]>&)>&, 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&) @ 0x0000000011841980 15. /build/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) @ 0x000000001621208e 16. /build/src/Storages/StorageReplicatedMergeTree.cpp:5228: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl[abi:se190107] const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000015f9a5fe 17. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000015ed8bfd 18. /build/src/Storages/StorageReplicatedMergeTree.cpp:2514: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x0000000015ec9aab 19. /build/src/Storages/StorageReplicatedMergeTree.cpp:2349: DB::StorageReplicatedMergeTree::executeLogEntry(DB::ReplicatedMergeTreeLogEntry&) @ 0x0000000015eba91b 20. /build/src/Storages/StorageReplicatedMergeTree.cpp:3876: bool std::__function::__policy_invoker&)>::__call_impl[abi:se190107])::$_1, bool (std::shared_ptr&)>>(std::__function::__policy_storage const*, std::shared_ptr&) @ 0x0000000015f9837e 21. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000165d6fc3 22. /build/src/Storages/StorageReplicatedMergeTree.cpp:3872: DB::StorageReplicatedMergeTree::processQueueEntry(std::shared_ptr) @ 0x0000000015efc18a 23. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001624c1b2 24. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000162f9c70 25. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x00000000162fa55a 26. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc6653 27. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000000fccc4c3 28. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc3d92 29. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fcca080 30. ? @ 0x00007fbc6213eac3 31. ? @ 0x00007fbc621d0850 (version 25.3.6.10636.altinitytest (altinity build)) 2025.07.28 11:57:49.512441 [ 3971 ] {} test_13.rmt2 (7f9b740d-015c-470e-8cc6-8ba33be0dc63): auto DB::StorageReplicatedMergeTree::processQueueEntry(ReplicatedMergeTreeQueue::SelectedEntryPtr)::(anonymous class)::operator()(LogEntryPtr &) const: Code: 86. DB::HTTPException: Received error from remote server http://146b4357c08d:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Ftest%2F01165%2Ftest_13%2Frmt%2Freplicas%2F1&part=20250728_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.6.10636.altinitytest (altinity build)) '. (RECEIVED_ERROR_FROM_REMOTE_IO_SERVER), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.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 const&, int&&, String const&, unsigned long&&, String const&) @ 0x000000000feda8d9 4. /build/src/IO/HTTPCommon.cpp:104: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x000000000feda6e2 5. /build/src/IO/HTTPCommon.cpp:93: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x000000000feda537 6. /build/src/IO/ReadWriteBufferFromHTTP.cpp:277: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x000000001184a4c4 7. /build/src/IO/ReadWriteBufferFromHTTP.cpp:285: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x000000001184a615 8. /build/src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x000000001184ae59 9. /build/src/IO/ReadWriteBufferFromHTTP.cpp:472: void std::__function::__policy_invoker::__call_impl[abi:se190107]>(std::__function::__policy_storage const*) @ 0x000000001184cedd 10. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001184858b 11. /build/src/IO/ReadWriteBufferFromHTTP.cpp:465: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x000000001184bf0b 12. /build/src/IO/ReadBuffer.h:60: DB::ReadBuffer::next() @ 0x000000000a148c7b 13. /build/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) @ 0x0000000011849fb2 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]>&)>&, 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&) @ 0x0000000011841980 15. /build/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) @ 0x000000001621208e 16. /build/src/Storages/StorageReplicatedMergeTree.cpp:5228: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl[abi:se190107] const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000015f9a5fe 17. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000015ed8bfd 18. /build/src/Storages/StorageReplicatedMergeTree.cpp:2514: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x0000000015ec9aab 19. /build/src/Storages/StorageReplicatedMergeTree.cpp:2349: DB::StorageReplicatedMergeTree::executeLogEntry(DB::ReplicatedMergeTreeLogEntry&) @ 0x0000000015eba91b 20. /build/src/Storages/StorageReplicatedMergeTree.cpp:3876: bool std::__function::__policy_invoker&)>::__call_impl[abi:se190107])::$_1, bool (std::shared_ptr&)>>(std::__function::__policy_storage const*, std::shared_ptr&) @ 0x0000000015f9837e 21. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000165d6fc3 22. /build/src/Storages/StorageReplicatedMergeTree.cpp:3872: DB::StorageReplicatedMergeTree::processQueueEntry(std::shared_ptr) @ 0x0000000015efc18a 23. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001624c1b2 24. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000162f9c70 25. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x00000000162fa55a 26. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc6653 27. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000000fccc4c3 28. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc3d92 29. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fcca080 30. ? @ 0x00007fbc6213eac3 31. ? @ 0x00007fbc621d0850 (version 25.3.6.10636.altinitytest (altinity build)) 2025.07.28 11:57:50.418435 [ 17270 ] {f49557d7-a7f5-4ebe-99cf-7c7e547ef44c} executeQuery: Code: 36. DB::Exception: Polygon is not valid: Geometry has invalid self-intersections. A self-intersection point was found at (5.34483, 4.65517); method: i; operations: u/i; segment IDs {source, multi, ring, segment}: {0, -1, -1, 1}/{0, -1, -1, 6}: In scope SELECT pointInPolygon((0.1, 0.1), [(0.5, 0.), (1., 0.), (8., 7.5), (7.5, 8.), (0., 1.), (0., 0.5), (4.5, 5.5), (5.5, 4.5), (0.5, 0.)]). (BAD_ARGUMENTS) (version 25.3.6.10636.altinitytest (altinity build)) (from [::1]:54592) (comment: 00500_point_in_polygon.sql) (query 19, line 21) (in query: SELECT pointInPolygon((0.1, 0.1), [(0.5, 0.), (1.0, 0.), (8.0, 7.5), (7.5, 8.0), (0., 1.), (0., 0.5), (4.5, 5.5), (5.5, 4.5), (0.5, 0.0)]);), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x000000000a080b2b 4. /build/src/Functions/pointInPolygon.cpp:580: DB::(anonymous namespace)::FunctionPointInPolygon>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000e0785f5 5. /build/src/Functions/IFunction.h:437: DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000a069f2a 6. /build/src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000012d9965a 7. /build/src/Functions/IFunction.cpp:351: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d93b02 8. /build/src/Functions/IFunction.cpp:420: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d95059 9. /build/src/Functions/IFunction.cpp:498: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d95c72 10. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3567: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000014034494 11. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3838: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000014019a9e 12. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3980: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000014018e31 13. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:4304: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000014042fa7 14. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5605: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000014013749 15. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000140127f9 16. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000014011fce 17. /build/src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000001406ce8a 18. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000014973b42 19. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000001497268d 20. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000014974d24 21. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001492924b 22. /build/src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88641 23. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 24. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 25. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 26. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 27. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 28. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 29. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 30. ? @ 0x00007fbc6213eac3 31. ? @ 0x00007fbc621d0850 2025.07.28 11:57:50.427538 [ 17270 ] {} TCPHandler: Code: 36. DB::Exception: Polygon is not valid: Geometry has invalid self-intersections. A self-intersection point was found at (5.34483, 4.65517); method: i; operations: u/i; segment IDs {source, multi, ring, segment}: {0, -1, -1, 1}/{0, -1, -1, 6}: In scope SELECT pointInPolygon((0.1, 0.1), [(0.5, 0.), (1., 0.), (8., 7.5), (7.5, 8.), (0., 1.), (0., 0.5), (4.5, 5.5), (5.5, 4.5), (0.5, 0.)]). (BAD_ARGUMENTS), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x000000000a080b2b 4. /build/src/Functions/pointInPolygon.cpp:580: DB::(anonymous namespace)::FunctionPointInPolygon>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000e0785f5 5. /build/src/Functions/IFunction.h:437: DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000a069f2a 6. /build/src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000012d9965a 7. /build/src/Functions/IFunction.cpp:351: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d93b02 8. /build/src/Functions/IFunction.cpp:420: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d95059 9. /build/src/Functions/IFunction.cpp:498: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d95c72 10. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3567: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000014034494 11. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3838: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000014019a9e 12. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3980: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000014018e31 13. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:4304: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000014042fa7 14. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5605: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000014013749 15. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000140127f9 16. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000014011fce 17. /build/src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000001406ce8a 18. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000014973b42 19. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000001497268d 20. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000014974d24 21. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001492924b 22. /build/src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88641 23. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 24. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 25. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 26. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 27. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 28. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 29. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 30. ? @ 0x00007fbc6213eac3 31. ? @ 0x00007fbc621d0850 2025.07.28 11:57:50.482478 [ 3967 ] {} test_13.rmt2 (7f9b740d-015c-470e-8cc6-8ba33be0dc63): auto DB::StorageReplicatedMergeTree::processQueueEntry(ReplicatedMergeTreeQueue::SelectedEntryPtr)::(anonymous class)::operator()(LogEntryPtr &) const: Code: 86. DB::HTTPException: Received error from remote server http://146b4357c08d:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Ftest%2F01165%2Ftest_13%2Frmt%2Freplicas%2F1&part=20250728_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.6.10636.altinitytest (altinity build)) '. (RECEIVED_ERROR_FROM_REMOTE_IO_SERVER), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.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 const&, int&&, String const&, unsigned long&&, String const&) @ 0x000000000feda8d9 4. /build/src/IO/HTTPCommon.cpp:104: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x000000000feda6e2 5. /build/src/IO/HTTPCommon.cpp:93: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x000000000feda537 6. /build/src/IO/ReadWriteBufferFromHTTP.cpp:277: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x000000001184a4c4 7. /build/src/IO/ReadWriteBufferFromHTTP.cpp:285: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x000000001184a615 8. /build/src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x000000001184ae59 9. /build/src/IO/ReadWriteBufferFromHTTP.cpp:472: void std::__function::__policy_invoker::__call_impl[abi:se190107]>(std::__function::__policy_storage const*) @ 0x000000001184cedd 10. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001184858b 11. /build/src/IO/ReadWriteBufferFromHTTP.cpp:465: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x000000001184bf0b 12. /build/src/IO/ReadBuffer.h:60: DB::ReadBuffer::next() @ 0x000000000a148c7b 13. /build/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) @ 0x0000000011849fb2 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]>&)>&, 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&) @ 0x0000000011841980 15. /build/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) @ 0x000000001621208e 16. /build/src/Storages/StorageReplicatedMergeTree.cpp:5228: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl[abi:se190107] const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000015f9a5fe 17. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000015ed8bfd 18. /build/src/Storages/StorageReplicatedMergeTree.cpp:2514: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x0000000015ec9aab 19. /build/src/Storages/StorageReplicatedMergeTree.cpp:2349: DB::StorageReplicatedMergeTree::executeLogEntry(DB::ReplicatedMergeTreeLogEntry&) @ 0x0000000015eba91b 20. /build/src/Storages/StorageReplicatedMergeTree.cpp:3876: bool std::__function::__policy_invoker&)>::__call_impl[abi:se190107])::$_1, bool (std::shared_ptr&)>>(std::__function::__policy_storage const*, std::shared_ptr&) @ 0x0000000015f9837e 21. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000165d6fc3 22. /build/src/Storages/StorageReplicatedMergeTree.cpp:3872: DB::StorageReplicatedMergeTree::processQueueEntry(std::shared_ptr) @ 0x0000000015efc18a 23. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001624c1b2 24. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000162f9c70 25. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x00000000162fa55a 26. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc6653 27. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000000fccc4c3 28. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc3d92 29. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fcca080 30. ? @ 0x00007fbc6213eac3 31. ? @ 0x00007fbc621d0850 (version 25.3.6.10636.altinitytest (altinity build)) 2025.07.28 11:57:50.486639 [ 17270 ] {65d72ea5-3d65-4979-832d-5ba095c745f6} executeQuery: Code: 36. DB::Exception: Polygon is not valid: Geometry has invalid self-intersections. A self-intersection point was found at (5.34483, 4.65517); method: i; operations: u/i; segment IDs {source, multi, ring, segment}: {0, -1, -1, 1}/{0, -1, -1, 6}: In scope SELECT pointInPolygon((1., 1.), [(0.5, 0.), (1., 0.), (8., 7.5), (7.5, 8.), (0., 1.), (0., 0.5), (4.5, 5.5), (5.5, 4.5), (0.5, 0.)]). (BAD_ARGUMENTS) (version 25.3.6.10636.altinitytest (altinity build)) (from [::1]:54592) (comment: 00500_point_in_polygon.sql) (query 20, line 22) (in query: SELECT pointInPolygon((1., 1.), [(0.5, 0.), (1.0, 0.), (8.0, 7.5), (7.5, 8.0), (0., 1.), (0., 0.5), (4.5, 5.5), (5.5, 4.5), (0.5, 0.0)]);), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x000000000a080b2b 4. /build/src/Functions/pointInPolygon.cpp:580: DB::(anonymous namespace)::FunctionPointInPolygon>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000e0785f5 5. /build/src/Functions/IFunction.h:437: DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000a069f2a 6. /build/src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000012d9965a 7. /build/src/Functions/IFunction.cpp:351: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d93b02 8. /build/src/Functions/IFunction.cpp:420: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d95059 9. /build/src/Functions/IFunction.cpp:498: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d95c72 10. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3567: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000014034494 11. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3838: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000014019a9e 12. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3980: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000014018e31 13. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:4304: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000014042fa7 14. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5605: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000014013749 15. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000140127f9 16. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000014011fce 17. /build/src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000001406ce8a 18. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000014973b42 19. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000001497268d 20. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000014974d24 21. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001492924b 22. /build/src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88641 23. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 24. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 25. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 26. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 27. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 28. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 29. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 30. ? @ 0x00007fbc6213eac3 31. ? @ 0x00007fbc621d0850 2025.07.28 11:57:50.489785 [ 17270 ] {} TCPHandler: Code: 36. DB::Exception: Polygon is not valid: Geometry has invalid self-intersections. A self-intersection point was found at (5.34483, 4.65517); method: i; operations: u/i; segment IDs {source, multi, ring, segment}: {0, -1, -1, 1}/{0, -1, -1, 6}: In scope SELECT pointInPolygon((1., 1.), [(0.5, 0.), (1., 0.), (8., 7.5), (7.5, 8.), (0., 1.), (0., 0.5), (4.5, 5.5), (5.5, 4.5), (0.5, 0.)]). (BAD_ARGUMENTS), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x000000000a080b2b 4. /build/src/Functions/pointInPolygon.cpp:580: DB::(anonymous namespace)::FunctionPointInPolygon>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000e0785f5 5. /build/src/Functions/IFunction.h:437: DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000a069f2a 6. /build/src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000012d9965a 7. /build/src/Functions/IFunction.cpp:351: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d93b02 8. /build/src/Functions/IFunction.cpp:420: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d95059 9. /build/src/Functions/IFunction.cpp:498: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d95c72 10. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3567: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000014034494 11. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3838: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000014019a9e 12. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3980: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000014018e31 13. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:4304: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000014042fa7 14. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5605: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000014013749 15. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000140127f9 16. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000014011fce 17. /build/src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000001406ce8a 18. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000014973b42 19. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000001497268d 20. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000014974d24 21. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001492924b 22. /build/src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88641 23. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 24. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 25. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 26. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 27. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 28. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 29. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 30. ? @ 0x00007fbc6213eac3 31. ? @ 0x00007fbc621d0850 2025.07.28 11:57:50.564368 [ 17270 ] {20b38fb5-dc05-400f-b2ac-111e32ea427b} executeQuery: Code: 36. DB::Exception: Polygon is not valid: Geometry has invalid self-intersections. A self-intersection point was found at (5.34483, 4.65517); method: i; operations: u/i; segment IDs {source, multi, ring, segment}: {0, -1, -1, 1}/{0, -1, -1, 6}: In scope SELECT pointInPolygon((0.7, 0.1), [(0.5, 0.), (1., 0.), (8., 7.5), (7.5, 8.), (0., 1.), (0., 0.5), (4.5, 5.5), (5.5, 4.5), (0.5, 0.)]). (BAD_ARGUMENTS) (version 25.3.6.10636.altinitytest (altinity build)) (from [::1]:54592) (comment: 00500_point_in_polygon.sql) (query 21, line 23) (in query: SELECT pointInPolygon((0.7, 0.1), [(0.5, 0.), (1.0, 0.), (8.0, 7.5), (7.5, 8.0), (0., 1.), (0., 0.5), (4.5, 5.5), (5.5, 4.5), (0.5, 0.0)]);), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x000000000a080b2b 4. /build/src/Functions/pointInPolygon.cpp:580: DB::(anonymous namespace)::FunctionPointInPolygon>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000e0785f5 5. /build/src/Functions/IFunction.h:437: DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000a069f2a 6. /build/src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000012d9965a 7. /build/src/Functions/IFunction.cpp:351: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d93b02 8. /build/src/Functions/IFunction.cpp:420: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d95059 9. /build/src/Functions/IFunction.cpp:498: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d95c72 10. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3567: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000014034494 11. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3838: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000014019a9e 12. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3980: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000014018e31 13. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:4304: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000014042fa7 14. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5605: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000014013749 15. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000140127f9 16. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000014011fce 17. /build/src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000001406ce8a 18. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000014973b42 19. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000001497268d 20. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000014974d24 21. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001492924b 22. /build/src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88641 23. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 24. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 25. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 26. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 27. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 28. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 29. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 30. ? @ 0x00007fbc6213eac3 31. ? @ 0x00007fbc621d0850 2025.07.28 11:57:50.568137 [ 17270 ] {} TCPHandler: Code: 36. DB::Exception: Polygon is not valid: Geometry has invalid self-intersections. A self-intersection point was found at (5.34483, 4.65517); method: i; operations: u/i; segment IDs {source, multi, ring, segment}: {0, -1, -1, 1}/{0, -1, -1, 6}: In scope SELECT pointInPolygon((0.7, 0.1), [(0.5, 0.), (1., 0.), (8., 7.5), (7.5, 8.), (0., 1.), (0., 0.5), (4.5, 5.5), (5.5, 4.5), (0.5, 0.)]). (BAD_ARGUMENTS), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x000000000a080b2b 4. /build/src/Functions/pointInPolygon.cpp:580: DB::(anonymous namespace)::FunctionPointInPolygon>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000e0785f5 5. /build/src/Functions/IFunction.h:437: DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000a069f2a 6. /build/src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000012d9965a 7. /build/src/Functions/IFunction.cpp:351: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d93b02 8. /build/src/Functions/IFunction.cpp:420: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d95059 9. /build/src/Functions/IFunction.cpp:498: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d95c72 10. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3567: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000014034494 11. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3838: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000014019a9e 12. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3980: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000014018e31 13. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:4304: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000014042fa7 14. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5605: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000014013749 15. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000140127f9 16. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000014011fce 17. /build/src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000001406ce8a 18. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000014973b42 19. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000001497268d 20. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000014974d24 21. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001492924b 22. /build/src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88641 23. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 24. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 25. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 26. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 27. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 28. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 29. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 30. ? @ 0x00007fbc6213eac3 31. ? @ 0x00007fbc621d0850 2025.07.28 11:57:50.601853 [ 17270 ] {aab3685d-14ab-471b-9317-7b2506607134} executeQuery: Code: 36. DB::Exception: Polygon is not valid: Geometry has invalid self-intersections. A self-intersection point was found at (5.34483, 4.65517); method: i; operations: u/i; segment IDs {source, multi, ring, segment}: {0, -1, -1, 1}/{0, -1, -1, 6}: In scope SELECT pointInPolygon((0.1, 0.7), [(0.5, 0.), (1., 0.), (8., 7.5), (7.5, 8.), (0., 1.), (0., 0.5), (4.5, 5.5), (5.5, 4.5), (0.5, 0.)]). (BAD_ARGUMENTS) (version 25.3.6.10636.altinitytest (altinity build)) (from [::1]:54592) (comment: 00500_point_in_polygon.sql) (query 22, line 24) (in query: SELECT pointInPolygon((0.1, 0.7), [(0.5, 0.), (1.0, 0.), (8.0, 7.5), (7.5, 8.0), (0., 1.), (0., 0.5), (4.5, 5.5), (5.5, 4.5), (0.5, 0.0)]);), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x000000000a080b2b 4. /build/src/Functions/pointInPolygon.cpp:580: DB::(anonymous namespace)::FunctionPointInPolygon>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000e0785f5 5. /build/src/Functions/IFunction.h:437: DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000a069f2a 6. /build/src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000012d9965a 7. /build/src/Functions/IFunction.cpp:351: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d93b02 8. /build/src/Functions/IFunction.cpp:420: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d95059 9. /build/src/Functions/IFunction.cpp:498: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d95c72 10. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3567: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000014034494 11. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3838: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000014019a9e 12. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3980: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000014018e31 13. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:4304: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000014042fa7 14. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5605: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000014013749 15. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000140127f9 16. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000014011fce 17. /build/src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000001406ce8a 18. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000014973b42 19. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000001497268d 20. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000014974d24 21. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001492924b 22. /build/src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88641 23. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 24. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 25. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 26. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 27. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 28. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 29. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 30. ? @ 0x00007fbc6213eac3 31. ? @ 0x00007fbc621d0850 2025.07.28 11:57:50.604917 [ 17270 ] {} TCPHandler: Code: 36. DB::Exception: Polygon is not valid: Geometry has invalid self-intersections. A self-intersection point was found at (5.34483, 4.65517); method: i; operations: u/i; segment IDs {source, multi, ring, segment}: {0, -1, -1, 1}/{0, -1, -1, 6}: In scope SELECT pointInPolygon((0.1, 0.7), [(0.5, 0.), (1., 0.), (8., 7.5), (7.5, 8.), (0., 1.), (0., 0.5), (4.5, 5.5), (5.5, 4.5), (0.5, 0.)]). (BAD_ARGUMENTS), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x000000000a080b2b 4. /build/src/Functions/pointInPolygon.cpp:580: DB::(anonymous namespace)::FunctionPointInPolygon>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000e0785f5 5. /build/src/Functions/IFunction.h:437: DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000a069f2a 6. /build/src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000012d9965a 7. /build/src/Functions/IFunction.cpp:351: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d93b02 8. /build/src/Functions/IFunction.cpp:420: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d95059 9. /build/src/Functions/IFunction.cpp:498: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d95c72 10. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3567: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000014034494 11. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3838: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000014019a9e 12. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3980: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000014018e31 13. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:4304: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000014042fa7 14. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5605: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000014013749 15. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000140127f9 16. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000014011fce 17. /build/src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000001406ce8a 18. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000014973b42 19. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000001497268d 20. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000014974d24 21. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001492924b 22. /build/src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88641 23. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 24. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 25. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 26. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 27. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 28. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 29. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 30. ? @ 0x00007fbc6213eac3 31. ? @ 0x00007fbc621d0850 2025.07.28 11:57:50.628084 [ 17270 ] {322ddd41-39a0-4330-9b80-fbe5a9255e58} executeQuery: Code: 36. DB::Exception: Polygon is not valid: Geometry has invalid self-intersections. A self-intersection point was found at (5.34483, 4.65517); method: i; operations: u/i; segment IDs {source, multi, ring, segment}: {0, -1, -1, 1}/{0, -1, -1, 6}: In scope SELECT pointInPolygon((1.1, 0.1), [(0.5, 0.), (1., 0.), (8., 7.5), (7.5, 8.), (0., 1.), (0., 0.5), (4.5, 5.5), (5.5, 4.5), (0.5, 0.)]). (BAD_ARGUMENTS) (version 25.3.6.10636.altinitytest (altinity build)) (from [::1]:54592) (comment: 00500_point_in_polygon.sql) (query 23, line 25) (in query: SELECT pointInPolygon((1.1, 0.1), [(0.5, 0.), (1.0, 0.), (8.0, 7.5), (7.5, 8.0), (0., 1.), (0., 0.5), (4.5, 5.5), (5.5, 4.5), (0.5, 0.0)]);), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x000000000a080b2b 4. /build/src/Functions/pointInPolygon.cpp:580: DB::(anonymous namespace)::FunctionPointInPolygon>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000e0785f5 5. /build/src/Functions/IFunction.h:437: DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000a069f2a 6. /build/src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000012d9965a 7. /build/src/Functions/IFunction.cpp:351: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d93b02 8. /build/src/Functions/IFunction.cpp:420: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d95059 9. /build/src/Functions/IFunction.cpp:498: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d95c72 10. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3567: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000014034494 11. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3838: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000014019a9e 12. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3980: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000014018e31 13. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:4304: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000014042fa7 14. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5605: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000014013749 15. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000140127f9 16. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000014011fce 17. /build/src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000001406ce8a 18. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000014973b42 19. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000001497268d 20. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000014974d24 21. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001492924b 22. /build/src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88641 23. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 24. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 25. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 26. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 27. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 28. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 29. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 30. ? @ 0x00007fbc6213eac3 31. ? @ 0x00007fbc621d0850 2025.07.28 11:57:50.630240 [ 17270 ] {} TCPHandler: Code: 36. DB::Exception: Polygon is not valid: Geometry has invalid self-intersections. A self-intersection point was found at (5.34483, 4.65517); method: i; operations: u/i; segment IDs {source, multi, ring, segment}: {0, -1, -1, 1}/{0, -1, -1, 6}: In scope SELECT pointInPolygon((1.1, 0.1), [(0.5, 0.), (1., 0.), (8., 7.5), (7.5, 8.), (0., 1.), (0., 0.5), (4.5, 5.5), (5.5, 4.5), (0.5, 0.)]). (BAD_ARGUMENTS), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x000000000a080b2b 4. /build/src/Functions/pointInPolygon.cpp:580: DB::(anonymous namespace)::FunctionPointInPolygon>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000e0785f5 5. /build/src/Functions/IFunction.h:437: DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000a069f2a 6. /build/src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000012d9965a 7. /build/src/Functions/IFunction.cpp:351: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d93b02 8. /build/src/Functions/IFunction.cpp:420: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d95059 9. /build/src/Functions/IFunction.cpp:498: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d95c72 10. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3567: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000014034494 11. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3838: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000014019a9e 12. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3980: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000014018e31 13. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:4304: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000014042fa7 14. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5605: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000014013749 15. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000140127f9 16. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000014011fce 17. /build/src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000001406ce8a 18. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000014973b42 19. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000001497268d 20. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000014974d24 21. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001492924b 22. /build/src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88641 23. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 24. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 25. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 26. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 27. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 28. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 29. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 30. ? @ 0x00007fbc6213eac3 31. ? @ 0x00007fbc621d0850 2025.07.28 11:57:50.667619 [ 17270 ] {810d8659-c17e-4fc7-ac76-9c700ef9e995} executeQuery: Code: 36. DB::Exception: Polygon is not valid: Geometry has invalid self-intersections. A self-intersection point was found at (5.34483, 4.65517); method: i; operations: u/i; segment IDs {source, multi, ring, segment}: {0, -1, -1, 1}/{0, -1, -1, 6}: In scope SELECT pointInPolygon((0.1, 1.1), [(0.5, 0.), (1., 0.), (8., 7.5), (7.5, 8.), (0., 1.), (0., 0.5), (4.5, 5.5), (5.5, 4.5), (0.5, 0.)]). (BAD_ARGUMENTS) (version 25.3.6.10636.altinitytest (altinity build)) (from [::1]:54592) (comment: 00500_point_in_polygon.sql) (query 24, line 26) (in query: SELECT pointInPolygon((0.1, 1.1), [(0.5, 0.), (1.0, 0.), (8.0, 7.5), (7.5, 8.0), (0., 1.), (0., 0.5), (4.5, 5.5), (5.5, 4.5), (0.5, 0.0)]);), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x000000000a080b2b 4. /build/src/Functions/pointInPolygon.cpp:580: DB::(anonymous namespace)::FunctionPointInPolygon>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000e0785f5 5. /build/src/Functions/IFunction.h:437: DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000a069f2a 6. /build/src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000012d9965a 7. /build/src/Functions/IFunction.cpp:351: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d93b02 8. /build/src/Functions/IFunction.cpp:420: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d95059 9. /build/src/Functions/IFunction.cpp:498: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d95c72 10. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3567: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000014034494 11. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3838: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000014019a9e 12. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3980: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000014018e31 13. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:4304: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000014042fa7 14. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5605: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000014013749 15. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000140127f9 16. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000014011fce 17. /build/src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000001406ce8a 18. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000014973b42 19. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000001497268d 20. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000014974d24 21. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001492924b 22. /build/src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88641 23. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 24. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 25. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 26. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 27. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 28. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 29. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 30. ? @ 0x00007fbc6213eac3 31. ? @ 0x00007fbc621d0850 2025.07.28 11:57:50.676006 [ 17270 ] {} TCPHandler: Code: 36. DB::Exception: Polygon is not valid: Geometry has invalid self-intersections. A self-intersection point was found at (5.34483, 4.65517); method: i; operations: u/i; segment IDs {source, multi, ring, segment}: {0, -1, -1, 1}/{0, -1, -1, 6}: In scope SELECT pointInPolygon((0.1, 1.1), [(0.5, 0.), (1., 0.), (8., 7.5), (7.5, 8.), (0., 1.), (0., 0.5), (4.5, 5.5), (5.5, 4.5), (0.5, 0.)]). (BAD_ARGUMENTS), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x000000000a080b2b 4. /build/src/Functions/pointInPolygon.cpp:580: DB::(anonymous namespace)::FunctionPointInPolygon>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000e0785f5 5. /build/src/Functions/IFunction.h:437: DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000a069f2a 6. /build/src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000012d9965a 7. /build/src/Functions/IFunction.cpp:351: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d93b02 8. /build/src/Functions/IFunction.cpp:420: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d95059 9. /build/src/Functions/IFunction.cpp:498: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d95c72 10. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3567: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000014034494 11. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3838: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000014019a9e 12. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3980: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000014018e31 13. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:4304: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000014042fa7 14. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5605: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000014013749 15. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000140127f9 16. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000014011fce 17. /build/src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000001406ce8a 18. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000014973b42 19. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000001497268d 20. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000014974d24 21. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001492924b 22. /build/src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88641 23. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 24. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 25. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 26. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 27. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 28. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 29. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 30. ? @ 0x00007fbc6213eac3 31. ? @ 0x00007fbc621d0850 2025.07.28 11:57:50.744039 [ 17270 ] {bf848ace-aa16-4115-903f-bf754946942a} executeQuery: Code: 36. DB::Exception: Polygon is not valid: Geometry has invalid self-intersections. A self-intersection point was found at (5.34483, 4.65517); method: i; operations: u/i; segment IDs {source, multi, ring, segment}: {0, -1, -1, 1}/{0, -1, -1, 6}: In scope SELECT pointInPolygon((5., 5.), [(0.5, 0.), (1., 0.), (8., 7.5), (7.5, 8.), (0., 1.), (0., 0.5), (4.5, 5.5), (5.5, 4.5), (0.5, 0.)]). (BAD_ARGUMENTS) (version 25.3.6.10636.altinitytest (altinity build)) (from [::1]:54592) (comment: 00500_point_in_polygon.sql) (query 25, line 27) (in query: SELECT pointInPolygon((5.0, 5.0), [(0.5, 0.), (1.0, 0.), (8.0, 7.5), (7.5, 8.0), (0., 1.), (0., 0.5), (4.5, 5.5), (5.5, 4.5), (0.5, 0.0)]);), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x000000000a080b2b 4. /build/src/Functions/pointInPolygon.cpp:580: DB::(anonymous namespace)::FunctionPointInPolygon>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000e0785f5 5. /build/src/Functions/IFunction.h:437: DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000a069f2a 6. /build/src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000012d9965a 7. /build/src/Functions/IFunction.cpp:351: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d93b02 8. /build/src/Functions/IFunction.cpp:420: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d95059 9. /build/src/Functions/IFunction.cpp:498: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d95c72 10. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3567: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000014034494 11. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3838: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000014019a9e 12. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3980: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000014018e31 13. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:4304: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000014042fa7 14. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5605: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000014013749 15. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000140127f9 16. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000014011fce 17. /build/src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000001406ce8a 18. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000014973b42 19. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000001497268d 20. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000014974d24 21. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001492924b 22. /build/src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88641 23. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 24. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 25. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 26. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 27. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 28. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 29. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 30. ? @ 0x00007fbc6213eac3 31. ? @ 0x00007fbc621d0850 2025.07.28 11:57:50.746849 [ 17270 ] {} TCPHandler: Code: 36. DB::Exception: Polygon is not valid: Geometry has invalid self-intersections. A self-intersection point was found at (5.34483, 4.65517); method: i; operations: u/i; segment IDs {source, multi, ring, segment}: {0, -1, -1, 1}/{0, -1, -1, 6}: In scope SELECT pointInPolygon((5., 5.), [(0.5, 0.), (1., 0.), (8., 7.5), (7.5, 8.), (0., 1.), (0., 0.5), (4.5, 5.5), (5.5, 4.5), (0.5, 0.)]). (BAD_ARGUMENTS), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x000000000a080b2b 4. /build/src/Functions/pointInPolygon.cpp:580: DB::(anonymous namespace)::FunctionPointInPolygon>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000e0785f5 5. /build/src/Functions/IFunction.h:437: DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000a069f2a 6. /build/src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000012d9965a 7. /build/src/Functions/IFunction.cpp:351: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d93b02 8. /build/src/Functions/IFunction.cpp:420: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d95059 9. /build/src/Functions/IFunction.cpp:498: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d95c72 10. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3567: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000014034494 11. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3838: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000014019a9e 12. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3980: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000014018e31 13. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:4304: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000014042fa7 14. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5605: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000014013749 15. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000140127f9 16. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000014011fce 17. /build/src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000001406ce8a 18. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000014973b42 19. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000001497268d 20. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000014974d24 21. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001492924b 22. /build/src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88641 23. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 24. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 25. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 26. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 27. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 28. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 29. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 30. ? @ 0x00007fbc6213eac3 31. ? @ 0x00007fbc621d0850 2025.07.28 11:57:50.771815 [ 17270 ] {2879029e-a5c4-4f1e-9798-a72d0ed95780} executeQuery: Code: 36. DB::Exception: Polygon is not valid: Geometry has invalid self-intersections. A self-intersection point was found at (5.34483, 4.65517); method: i; operations: u/i; segment IDs {source, multi, ring, segment}: {0, -1, -1, 1}/{0, -1, -1, 6}: In scope SELECT pointInPolygon((7.9, 7.9), [(0.5, 0.), (1., 0.), (8., 7.5), (7.5, 8.), (0., 1.), (0., 0.5), (4.5, 5.5), (5.5, 4.5), (0.5, 0.)]). (BAD_ARGUMENTS) (version 25.3.6.10636.altinitytest (altinity build)) (from [::1]:54592) (comment: 00500_point_in_polygon.sql) (query 26, line 28) (in query: SELECT pointInPolygon((7.9, 7.9), [(0.5, 0.), (1.0, 0.), (8.0, 7.5), (7.5, 8.0), (0., 1.), (0., 0.5), (4.5, 5.5), (5.5, 4.5), (0.5, 0.0)]);), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x000000000a080b2b 4. /build/src/Functions/pointInPolygon.cpp:580: DB::(anonymous namespace)::FunctionPointInPolygon>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000e0785f5 5. /build/src/Functions/IFunction.h:437: DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000a069f2a 6. /build/src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000012d9965a 7. /build/src/Functions/IFunction.cpp:351: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d93b02 8. /build/src/Functions/IFunction.cpp:420: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d95059 9. /build/src/Functions/IFunction.cpp:498: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d95c72 10. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3567: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000014034494 11. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3838: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000014019a9e 12. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3980: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000014018e31 13. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:4304: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000014042fa7 14. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5605: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000014013749 15. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000140127f9 16. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000014011fce 17. /build/src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000001406ce8a 18. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000014973b42 19. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000001497268d 20. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000014974d24 21. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001492924b 22. /build/src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88641 23. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 24. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 25. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 26. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 27. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 28. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 29. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 30. ? @ 0x00007fbc6213eac3 31. ? @ 0x00007fbc621d0850 2025.07.28 11:57:50.774645 [ 17270 ] {} TCPHandler: Code: 36. DB::Exception: Polygon is not valid: Geometry has invalid self-intersections. A self-intersection point was found at (5.34483, 4.65517); method: i; operations: u/i; segment IDs {source, multi, ring, segment}: {0, -1, -1, 1}/{0, -1, -1, 6}: In scope SELECT pointInPolygon((7.9, 7.9), [(0.5, 0.), (1., 0.), (8., 7.5), (7.5, 8.), (0., 1.), (0., 0.5), (4.5, 5.5), (5.5, 4.5), (0.5, 0.)]). (BAD_ARGUMENTS), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x000000000a080b2b 4. /build/src/Functions/pointInPolygon.cpp:580: DB::(anonymous namespace)::FunctionPointInPolygon>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000e0785f5 5. /build/src/Functions/IFunction.h:437: DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000a069f2a 6. /build/src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000012d9965a 7. /build/src/Functions/IFunction.cpp:351: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d93b02 8. /build/src/Functions/IFunction.cpp:420: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d95059 9. /build/src/Functions/IFunction.cpp:498: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d95c72 10. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3567: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000014034494 11. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3838: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000014019a9e 12. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3980: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000014018e31 13. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:4304: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000014042fa7 14. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5605: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000014013749 15. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000140127f9 16. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000014011fce 17. /build/src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000001406ce8a 18. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000014973b42 19. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000001497268d 20. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000014974d24 21. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001492924b 22. /build/src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88641 23. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 24. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 25. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 26. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 27. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 28. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 29. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 30. ? @ 0x00007fbc6213eac3 31. ? @ 0x00007fbc621d0850 2025.07.28 11:57:50.969713 [ 3965 ] {} test_13.rmt2 (7f9b740d-015c-470e-8cc6-8ba33be0dc63): auto DB::StorageReplicatedMergeTree::processQueueEntry(ReplicatedMergeTreeQueue::SelectedEntryPtr)::(anonymous class)::operator()(LogEntryPtr &) const: Code: 86. DB::HTTPException: Received error from remote server http://146b4357c08d:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Ftest%2F01165%2Ftest_13%2Frmt%2Freplicas%2F1&part=20250728_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.6.10636.altinitytest (altinity build)) '. (RECEIVED_ERROR_FROM_REMOTE_IO_SERVER), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.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 const&, int&&, String const&, unsigned long&&, String const&) @ 0x000000000feda8d9 4. /build/src/IO/HTTPCommon.cpp:104: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x000000000feda6e2 5. /build/src/IO/HTTPCommon.cpp:93: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x000000000feda537 6. /build/src/IO/ReadWriteBufferFromHTTP.cpp:277: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x000000001184a4c4 7. /build/src/IO/ReadWriteBufferFromHTTP.cpp:285: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x000000001184a615 8. /build/src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x000000001184ae59 9. /build/src/IO/ReadWriteBufferFromHTTP.cpp:472: void std::__function::__policy_invoker::__call_impl[abi:se190107]>(std::__function::__policy_storage const*) @ 0x000000001184cedd 10. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001184858b 11. /build/src/IO/ReadWriteBufferFromHTTP.cpp:465: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x000000001184bf0b 12. /build/src/IO/ReadBuffer.h:60: DB::ReadBuffer::next() @ 0x000000000a148c7b 13. /build/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) @ 0x0000000011849fb2 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]>&)>&, 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&) @ 0x0000000011841980 15. /build/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) @ 0x000000001621208e 16. /build/src/Storages/StorageReplicatedMergeTree.cpp:5228: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl[abi:se190107] const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000015f9a5fe 17. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000015ed8bfd 18. /build/src/Storages/StorageReplicatedMergeTree.cpp:2514: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x0000000015ec9aab 19. /build/src/Storages/StorageReplicatedMergeTree.cpp:2349: DB::StorageReplicatedMergeTree::executeLogEntry(DB::ReplicatedMergeTreeLogEntry&) @ 0x0000000015eba91b 20. /build/src/Storages/StorageReplicatedMergeTree.cpp:3876: bool std::__function::__policy_invoker&)>::__call_impl[abi:se190107])::$_1, bool (std::shared_ptr&)>>(std::__function::__policy_storage const*, std::shared_ptr&) @ 0x0000000015f9837e 21. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000165d6fc3 22. /build/src/Storages/StorageReplicatedMergeTree.cpp:3872: DB::StorageReplicatedMergeTree::processQueueEntry(std::shared_ptr) @ 0x0000000015efc18a 23. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001624c1b2 24. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000162f9c70 25. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x00000000162fa55a 26. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc6653 27. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000000fccc4c3 28. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc3d92 29. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fcca080 30. ? @ 0x00007fbc6213eac3 31. ? @ 0x00007fbc621d0850 (version 25.3.6.10636.altinitytest (altinity build)) 2025.07.28 11:57:51.018477 [ 3285 ] {} 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. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception>&, String>(int, FormatStringHelperImpl>&>::type, std::type_identity::type>, std::basic_string_view>&, String&&) @ 0x000000001385a5eb 4. /build/src/Access/SettingsConstraints.cpp:376: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000013859b18 5. /build/src/Access/SettingsConstraints.cpp:300: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000013858faf 6. /build/src/Access/SettingsConstraints.cpp:209: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000013859223 7. /build/src/Interpreters/Context.cpp:2690: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000014436134 8. /build/src/Interpreters/Context.cpp:2729: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x000000001443662b 9. /build/src/Server/HTTPHandler.cpp:457: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000001686d165 10. /build/src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x0000000016870807 11. /build/src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x0000000016907e99 12. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 13. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 14. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 15. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 16. ? @ 0x00007fbc6213eac3 17. ? @ 0x00007fbc621d0850 (version 25.3.6.10636.altinitytest (altinity build)) 2025.07.28 11:57:51.371863 [ 3972 ] {} test_13.rmt2 (7f9b740d-015c-470e-8cc6-8ba33be0dc63): auto DB::StorageReplicatedMergeTree::processQueueEntry(ReplicatedMergeTreeQueue::SelectedEntryPtr)::(anonymous class)::operator()(LogEntryPtr &) const: Code: 86. DB::HTTPException: Received error from remote server http://146b4357c08d:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Ftest%2F01165%2Ftest_13%2Frmt%2Freplicas%2F1&part=20250728_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.6.10636.altinitytest (altinity build)) '. (RECEIVED_ERROR_FROM_REMOTE_IO_SERVER), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.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 const&, int&&, String const&, unsigned long&&, String const&) @ 0x000000000feda8d9 4. /build/src/IO/HTTPCommon.cpp:104: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x000000000feda6e2 5. /build/src/IO/HTTPCommon.cpp:93: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x000000000feda537 6. /build/src/IO/ReadWriteBufferFromHTTP.cpp:277: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x000000001184a4c4 7. /build/src/IO/ReadWriteBufferFromHTTP.cpp:285: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x000000001184a615 8. /build/src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x000000001184ae59 9. /build/src/IO/ReadWriteBufferFromHTTP.cpp:472: void std::__function::__policy_invoker::__call_impl[abi:se190107]>(std::__function::__policy_storage const*) @ 0x000000001184cedd 10. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001184858b 11. /build/src/IO/ReadWriteBufferFromHTTP.cpp:465: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x000000001184bf0b 12. /build/src/IO/ReadBuffer.h:60: DB::ReadBuffer::next() @ 0x000000000a148c7b 13. /build/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) @ 0x0000000011849fb2 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]>&)>&, 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&) @ 0x0000000011841980 15. /build/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) @ 0x000000001621208e 16. /build/src/Storages/StorageReplicatedMergeTree.cpp:5228: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl[abi:se190107] const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000015f9a5fe 17. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000015ed8bfd 18. /build/src/Storages/StorageReplicatedMergeTree.cpp:2514: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x0000000015ec9aab 19. /build/src/Storages/StorageReplicatedMergeTree.cpp:2349: DB::StorageReplicatedMergeTree::executeLogEntry(DB::ReplicatedMergeTreeLogEntry&) @ 0x0000000015eba91b 20. /build/src/Storages/StorageReplicatedMergeTree.cpp:3876: bool std::__function::__policy_invoker&)>::__call_impl[abi:se190107])::$_1, bool (std::shared_ptr&)>>(std::__function::__policy_storage const*, std::shared_ptr&) @ 0x0000000015f9837e 21. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000165d6fc3 22. /build/src/Storages/StorageReplicatedMergeTree.cpp:3872: DB::StorageReplicatedMergeTree::processQueueEntry(std::shared_ptr) @ 0x0000000015efc18a 23. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001624c1b2 24. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000162f9c70 25. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x00000000162fa55a 26. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc6653 27. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000000fccc4c3 28. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc3d92 29. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fcca080 30. ? @ 0x00007fbc6213eac3 31. ? @ 0x00007fbc621d0850 (version 25.3.6.10636.altinitytest (altinity build)) 2025.07.28 11:57:52.371864 [ 3976 ] {} test_13.rmt2 (7f9b740d-015c-470e-8cc6-8ba33be0dc63): auto DB::StorageReplicatedMergeTree::processQueueEntry(ReplicatedMergeTreeQueue::SelectedEntryPtr)::(anonymous class)::operator()(LogEntryPtr &) const: Code: 86. DB::HTTPException: Received error from remote server http://146b4357c08d:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Ftest%2F01165%2Ftest_13%2Frmt%2Freplicas%2F1&part=20250728_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.6.10636.altinitytest (altinity build)) '. (RECEIVED_ERROR_FROM_REMOTE_IO_SERVER), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.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 const&, int&&, String const&, unsigned long&&, String const&) @ 0x000000000feda8d9 4. /build/src/IO/HTTPCommon.cpp:104: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x000000000feda6e2 5. /build/src/IO/HTTPCommon.cpp:93: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x000000000feda537 6. /build/src/IO/ReadWriteBufferFromHTTP.cpp:277: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x000000001184a4c4 7. /build/src/IO/ReadWriteBufferFromHTTP.cpp:285: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x000000001184a615 8. /build/src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x000000001184ae59 9. /build/src/IO/ReadWriteBufferFromHTTP.cpp:472: void std::__function::__policy_invoker::__call_impl[abi:se190107]>(std::__function::__policy_storage const*) @ 0x000000001184cedd 10. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001184858b 11. /build/src/IO/ReadWriteBufferFromHTTP.cpp:465: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x000000001184bf0b 12. /build/src/IO/ReadBuffer.h:60: DB::ReadBuffer::next() @ 0x000000000a148c7b 13. /build/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) @ 0x0000000011849fb2 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]>&)>&, 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&) @ 0x0000000011841980 15. /build/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) @ 0x000000001621208e 16. /build/src/Storages/StorageReplicatedMergeTree.cpp:5228: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl[abi:se190107] const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000015f9a5fe 17. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000015ed8bfd 18. /build/src/Storages/StorageReplicatedMergeTree.cpp:2514: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x0000000015ec9aab 19. /build/src/Storages/StorageReplicatedMergeTree.cpp:2349: DB::StorageReplicatedMergeTree::executeLogEntry(DB::ReplicatedMergeTreeLogEntry&) @ 0x0000000015eba91b 20. /build/src/Storages/StorageReplicatedMergeTree.cpp:3876: bool std::__function::__policy_invoker&)>::__call_impl[abi:se190107])::$_1, bool (std::shared_ptr&)>>(std::__function::__policy_storage const*, std::shared_ptr&) @ 0x0000000015f9837e 21. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000165d6fc3 22. /build/src/Storages/StorageReplicatedMergeTree.cpp:3872: DB::StorageReplicatedMergeTree::processQueueEntry(std::shared_ptr) @ 0x0000000015efc18a 23. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001624c1b2 24. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000162f9c70 25. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x00000000162fa55a 26. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc6653 27. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000000fccc4c3 28. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc3d92 29. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fcca080 30. ? @ 0x00007fbc6213eac3 31. ? @ 0x00007fbc621d0850 (version 25.3.6.10636.altinitytest (altinity build)) 2025.07.28 11:57:53.448245 [ 3960 ] {} test_13.rmt2 (7f9b740d-015c-470e-8cc6-8ba33be0dc63): auto DB::StorageReplicatedMergeTree::processQueueEntry(ReplicatedMergeTreeQueue::SelectedEntryPtr)::(anonymous class)::operator()(LogEntryPtr &) const: Code: 86. DB::HTTPException: Received error from remote server http://146b4357c08d:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Ftest%2F01165%2Ftest_13%2Frmt%2Freplicas%2F1&part=20250728_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.6.10636.altinitytest (altinity build)) '. (RECEIVED_ERROR_FROM_REMOTE_IO_SERVER), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.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 const&, int&&, String const&, unsigned long&&, String const&) @ 0x000000000feda8d9 4. /build/src/IO/HTTPCommon.cpp:104: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x000000000feda6e2 5. /build/src/IO/HTTPCommon.cpp:93: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x000000000feda537 6. /build/src/IO/ReadWriteBufferFromHTTP.cpp:277: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x000000001184a4c4 7. /build/src/IO/ReadWriteBufferFromHTTP.cpp:285: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x000000001184a615 8. /build/src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x000000001184ae59 9. /build/src/IO/ReadWriteBufferFromHTTP.cpp:472: void std::__function::__policy_invoker::__call_impl[abi:se190107]>(std::__function::__policy_storage const*) @ 0x000000001184cedd 10. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001184858b 11. /build/src/IO/ReadWriteBufferFromHTTP.cpp:465: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x000000001184bf0b 12. /build/src/IO/ReadBuffer.h:60: DB::ReadBuffer::next() @ 0x000000000a148c7b 13. /build/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) @ 0x0000000011849fb2 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]>&)>&, 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&) @ 0x0000000011841980 15. /build/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) @ 0x000000001621208e 16. /build/src/Storages/StorageReplicatedMergeTree.cpp:5228: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl[abi:se190107] const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000015f9a5fe 17. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000015ed8bfd 18. /build/src/Storages/StorageReplicatedMergeTree.cpp:2514: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x0000000015ec9aab 19. /build/src/Storages/StorageReplicatedMergeTree.cpp:2349: DB::StorageReplicatedMergeTree::executeLogEntry(DB::ReplicatedMergeTreeLogEntry&) @ 0x0000000015eba91b 20. /build/src/Storages/StorageReplicatedMergeTree.cpp:3876: bool std::__function::__policy_invoker&)>::__call_impl[abi:se190107])::$_1, bool (std::shared_ptr&)>>(std::__function::__policy_storage const*, std::shared_ptr&) @ 0x0000000015f9837e 21. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000165d6fc3 22. /build/src/Storages/StorageReplicatedMergeTree.cpp:3872: DB::StorageReplicatedMergeTree::processQueueEntry(std::shared_ptr) @ 0x0000000015efc18a 23. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001624c1b2 24. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000162f9c70 25. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x00000000162fa55a 26. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc6653 27. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000000fccc4c3 28. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc3d92 29. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fcca080 30. ? @ 0x00007fbc6213eac3 31. ? @ 0x00007fbc621d0850 (version 25.3.6.10636.altinitytest (altinity build)) 2025.07.28 11:57:54.199392 [ 3963 ] {} test_13.rmt2 (7f9b740d-015c-470e-8cc6-8ba33be0dc63): auto DB::StorageReplicatedMergeTree::processQueueEntry(ReplicatedMergeTreeQueue::SelectedEntryPtr)::(anonymous class)::operator()(LogEntryPtr &) const: Code: 86. DB::HTTPException: Received error from remote server http://146b4357c08d:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Ftest%2F01165%2Ftest_13%2Frmt%2Freplicas%2F1&part=20250728_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.6.10636.altinitytest (altinity build)) '. (RECEIVED_ERROR_FROM_REMOTE_IO_SERVER), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.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 const&, int&&, String const&, unsigned long&&, String const&) @ 0x000000000feda8d9 4. /build/src/IO/HTTPCommon.cpp:104: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x000000000feda6e2 5. /build/src/IO/HTTPCommon.cpp:93: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x000000000feda537 6. /build/src/IO/ReadWriteBufferFromHTTP.cpp:277: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x000000001184a4c4 7. /build/src/IO/ReadWriteBufferFromHTTP.cpp:285: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x000000001184a615 8. /build/src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x000000001184ae59 9. /build/src/IO/ReadWriteBufferFromHTTP.cpp:472: void std::__function::__policy_invoker::__call_impl[abi:se190107]>(std::__function::__policy_storage const*) @ 0x000000001184cedd 10. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001184858b 11. /build/src/IO/ReadWriteBufferFromHTTP.cpp:465: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x000000001184bf0b 12. /build/src/IO/ReadBuffer.h:60: DB::ReadBuffer::next() @ 0x000000000a148c7b 13. /build/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) @ 0x0000000011849fb2 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]>&)>&, 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&) @ 0x0000000011841980 15. /build/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) @ 0x000000001621208e 16. /build/src/Storages/StorageReplicatedMergeTree.cpp:5228: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl[abi:se190107] const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000015f9a5fe 17. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000015ed8bfd 18. /build/src/Storages/StorageReplicatedMergeTree.cpp:2514: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x0000000015ec9aab 19. /build/src/Storages/StorageReplicatedMergeTree.cpp:2349: DB::StorageReplicatedMergeTree::executeLogEntry(DB::ReplicatedMergeTreeLogEntry&) @ 0x0000000015eba91b 20. /build/src/Storages/StorageReplicatedMergeTree.cpp:3876: bool std::__function::__policy_invoker&)>::__call_impl[abi:se190107])::$_1, bool (std::shared_ptr&)>>(std::__function::__policy_storage const*, std::shared_ptr&) @ 0x0000000015f9837e 21. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000165d6fc3 22. /build/src/Storages/StorageReplicatedMergeTree.cpp:3872: DB::StorageReplicatedMergeTree::processQueueEntry(std::shared_ptr) @ 0x0000000015efc18a 23. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001624c1b2 24. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000162f9c70 25. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x00000000162fa55a 26. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc6653 27. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000000fccc4c3 28. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc3d92 29. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fcca080 30. ? @ 0x00007fbc6213eac3 31. ? @ 0x00007fbc621d0850 (version 25.3.6.10636.altinitytest (altinity build)) 2025.07.28 11:57:54.813414 [ 11826 ] {f54d83b7-bd0d-4b0b-8311-135e4dce1103} executeQuery: Code: 439. DB::Exception: Cannot schedule a task: failed to start the thread (threads=2, jobs=1). (CANNOT_SCHEDULE_TASK) (version 25.3.6.10636.altinitytest (altinity build)) (from [::ffff:127.0.0.1]:43490) (comment: 02344_distinct_limit_distiributed.sql) (query 14, line 20) (in query: SELECT DISTINCT `__table1`.`id` AS `id` FROM `test_e77n07yz`.`t_distinct_limit` AS `__table1` LIMIT _CAST(10, 'UInt64')), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000fccaeeb 4. /build/src/Common/ThreadPool.cpp:275: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000fccc813 5. /build/src/Common/ThreadPool.cpp:308: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fcc8286 6. /build/src/Common/ThreadPool.cpp:506: ThreadPoolImpl>::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000000fcc8c8d 7. /build/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) @ 0x00000000163f6c3a 8. /build/src/Processors/QueryPlan/ReadFromMergeTree.cpp:1810: 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) @ 0x0000000016e2b73d 9. /build/src/Processors/QueryPlan/ReadFromMergeTree.cpp:1516: DB::ReadFromMergeTree::selectRangesToRead(std::vector, std::allocator>>, bool) const @ 0x0000000016e2a679 10. /build/src/Processors/QueryPlan/ReadFromMergeTree.cpp:1511: DB::ReadFromMergeTree::selectRangesToRead(bool) const @ 0x0000000016e2a472 11. /build/src/Processors/QueryPlan/ReadFromMergeTree.cpp:1998: DB::ReadFromMergeTree::initializePipeline(DB::QueryPipelineBuilder&, DB::BuildQueryPipelineSettings const&) @ 0x0000000016e3248c 12. /build/src/Processors/QueryPlan/ISourceStep.cpp:20: DB::ISourceStep::updatePipeline(std::vector>, std::allocator>>>, DB::BuildQueryPipelineSettings const&) @ 0x0000000016dd18d0 13. /build/src/Processors/QueryPlan/QueryPlan.cpp:201: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x0000000016e0076f 14. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:275: DB::InterpreterSelectQueryAnalyzer::buildQueryPipeline() @ 0x0000000014974614 15. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:242: DB::InterpreterSelectQueryAnalyzer::execute() @ 0x000000001497439e 16. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88dc9 17. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 18. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 19. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 20. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 21. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 22. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 23. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 24. ? @ 0x00007fbc6213eac3 25. ? @ 0x00007fbc621d0850 2025.07.28 11:57:54.817732 [ 11826 ] {} TCPHandler: Code: 439. DB::Exception: Cannot schedule a task: failed to start the thread (threads=2, jobs=1). (CANNOT_SCHEDULE_TASK), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000fccaeeb 4. /build/src/Common/ThreadPool.cpp:275: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000fccc813 5. /build/src/Common/ThreadPool.cpp:308: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fcc8286 6. /build/src/Common/ThreadPool.cpp:506: ThreadPoolImpl>::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000000fcc8c8d 7. /build/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) @ 0x00000000163f6c3a 8. /build/src/Processors/QueryPlan/ReadFromMergeTree.cpp:1810: 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) @ 0x0000000016e2b73d 9. /build/src/Processors/QueryPlan/ReadFromMergeTree.cpp:1516: DB::ReadFromMergeTree::selectRangesToRead(std::vector, std::allocator>>, bool) const @ 0x0000000016e2a679 10. /build/src/Processors/QueryPlan/ReadFromMergeTree.cpp:1511: DB::ReadFromMergeTree::selectRangesToRead(bool) const @ 0x0000000016e2a472 11. /build/src/Processors/QueryPlan/ReadFromMergeTree.cpp:1998: DB::ReadFromMergeTree::initializePipeline(DB::QueryPipelineBuilder&, DB::BuildQueryPipelineSettings const&) @ 0x0000000016e3248c 12. /build/src/Processors/QueryPlan/ISourceStep.cpp:20: DB::ISourceStep::updatePipeline(std::vector>, std::allocator>>>, DB::BuildQueryPipelineSettings const&) @ 0x0000000016dd18d0 13. /build/src/Processors/QueryPlan/QueryPlan.cpp:201: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x0000000016e0076f 14. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:275: DB::InterpreterSelectQueryAnalyzer::buildQueryPipeline() @ 0x0000000014974614 15. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:242: DB::InterpreterSelectQueryAnalyzer::execute() @ 0x000000001497439e 16. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88dc9 17. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 18. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 19. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 20. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 21. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 22. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 23. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 24. ? @ 0x00007fbc6213eac3 25. ? @ 0x00007fbc621d0850 2025.07.28 11:57:54.878952 [ 17255 ] {5f444918-9213-40b3-9ec3-2c00560768e6} executeQuery: Code: 439. DB::Exception: Received from 127.0.0.2:9000. DB::Exception: Cannot schedule a task: failed to start the thread (threads=2, jobs=1). Stack trace: 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000fccaeeb 4. /build/src/Common/ThreadPool.cpp:275: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000fccc813 5. /build/src/Common/ThreadPool.cpp:308: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fcc8286 6. /build/src/Common/ThreadPool.cpp:506: ThreadPoolImpl>::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000000fcc8c8d 7. /build/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) @ 0x00000000163f6c3a 8. /build/src/Processors/QueryPlan/ReadFromMergeTree.cpp:1810: 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) @ 0x0000000016e2b73d 9. /build/src/Processors/QueryPlan/ReadFromMergeTree.cpp:1516: DB::ReadFromMergeTree::selectRangesToRead(std::vector, std::allocator>>, bool) const @ 0x0000000016e2a679 10. /build/src/Processors/QueryPlan/ReadFromMergeTree.cpp:1511: DB::ReadFromMergeTree::selectRangesToRead(bool) const @ 0x0000000016e2a472 11. /build/src/Processors/QueryPlan/ReadFromMergeTree.cpp:1998: DB::ReadFromMergeTree::initializePipeline(DB::QueryPipelineBuilder&, DB::BuildQueryPipelineSettings const&) @ 0x0000000016e3248c 12. /build/src/Processors/QueryPlan/ISourceStep.cpp:20: DB::ISourceStep::updatePipeline(std::vector>, std::allocator>>>, DB::BuildQueryPipelineSettings const&) @ 0x0000000016dd18d0 13. /build/src/Processors/QueryPlan/QueryPlan.cpp:201: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x0000000016e0076f 14. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:275: DB::InterpreterSelectQueryAnalyzer::buildQueryPipeline() @ 0x0000000014974614 15. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:242: DB::InterpreterSelectQueryAnalyzer::execute() @ 0x000000001497439e 16. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88dc9 17. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 18. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 19. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 20. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 21. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 22. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 23. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 24. ? @ 0x00007fbc6213eac3 25. ? @ 0x00007fbc621d0850 : While executing Remote. (CANNOT_SCHEDULE_TASK) (version 25.3.6.10636.altinitytest (altinity build)) (from [::1]:54674) (comment: 02344_distinct_limit_distiributed.sql) (query 14, line 20) (in query: select id from ( select distinct id from remote('127.0.0.1,127.0.0.2', currentDatabase(),t_distinct_limit) limit 10 ) order by id;), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:111: DB::readException(DB::ReadBuffer&, String const&, bool) @ 0x000000000fc6e157 3. /build/src/Client/Connection.cpp:1445: DB::Connection::receiveException() const @ 0x00000000167d4127 4. /build/src/Client/Connection.cpp:1274: DB::Connection::receivePacket() @ 0x00000000167db312 5. /build/src/Client/PacketReceiver.cpp:66: DB::PacketReceiver::Task::run(std::function, std::function) @ 0x0000000016819393 6. /build/src/Common/AsyncTaskExecutor.cpp:89: DB::AsyncTaskExecutor::Routine::operator()(std::function) @ 0x0000000013bd1892 7. /build/src/Common/Fiber.h:76: boost::context::detail::fiber_record>::run(void*) @ 0x0000000013bd16fa 8. /build/contrib/boost/boost/context/fiber_fcontext.hpp:97: void boost::context::detail::fiber_entry>>(boost::context::detail::transfer_t) @ 0x0000000013bd1621 2025.07.28 11:57:54.993524 [ 17255 ] {} TCPHandler: Code: 439. DB::Exception: Received from 127.0.0.2:9000. DB::Exception: Cannot schedule a task: failed to start the thread (threads=2, jobs=1). Stack trace: 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000fccaeeb 4. /build/src/Common/ThreadPool.cpp:275: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000fccc813 5. /build/src/Common/ThreadPool.cpp:308: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fcc8286 6. /build/src/Common/ThreadPool.cpp:506: ThreadPoolImpl>::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000000fcc8c8d 7. /build/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) @ 0x00000000163f6c3a 8. /build/src/Processors/QueryPlan/ReadFromMergeTree.cpp:1810: 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) @ 0x0000000016e2b73d 9. /build/src/Processors/QueryPlan/ReadFromMergeTree.cpp:1516: DB::ReadFromMergeTree::selectRangesToRead(std::vector, std::allocator>>, bool) const @ 0x0000000016e2a679 10. /build/src/Processors/QueryPlan/ReadFromMergeTree.cpp:1511: DB::ReadFromMergeTree::selectRangesToRead(bool) const @ 0x0000000016e2a472 11. /build/src/Processors/QueryPlan/ReadFromMergeTree.cpp:1998: DB::ReadFromMergeTree::initializePipeline(DB::QueryPipelineBuilder&, DB::BuildQueryPipelineSettings const&) @ 0x0000000016e3248c 12. /build/src/Processors/QueryPlan/ISourceStep.cpp:20: DB::ISourceStep::updatePipeline(std::vector>, std::allocator>>>, DB::BuildQueryPipelineSettings const&) @ 0x0000000016dd18d0 13. /build/src/Processors/QueryPlan/QueryPlan.cpp:201: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x0000000016e0076f 14. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:275: DB::InterpreterSelectQueryAnalyzer::buildQueryPipeline() @ 0x0000000014974614 15. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:242: DB::InterpreterSelectQueryAnalyzer::execute() @ 0x000000001497439e 16. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88dc9 17. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 18. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 19. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 20. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 21. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 22. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 23. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 24. ? @ 0x00007fbc6213eac3 25. ? @ 0x00007fbc621d0850 : While executing Remote. (CANNOT_SCHEDULE_TASK), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:111: DB::readException(DB::ReadBuffer&, String const&, bool) @ 0x000000000fc6e157 3. /build/src/Client/Connection.cpp:1445: DB::Connection::receiveException() const @ 0x00000000167d4127 4. /build/src/Client/Connection.cpp:1274: DB::Connection::receivePacket() @ 0x00000000167db312 5. /build/src/Client/PacketReceiver.cpp:66: DB::PacketReceiver::Task::run(std::function, std::function) @ 0x0000000016819393 6. /build/src/Common/AsyncTaskExecutor.cpp:89: DB::AsyncTaskExecutor::Routine::operator()(std::function) @ 0x0000000013bd1892 7. /build/src/Common/Fiber.h:76: boost::context::detail::fiber_record>::run(void*) @ 0x0000000013bd16fa 8. /build/contrib/boost/boost/context/fiber_fcontext.hpp:97: void boost::context::detail::fiber_entry>>(boost::context::detail::transfer_t) @ 0x0000000013bd1621 Job's origin stack trace: 0. /build/src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000000fc33b84 1. /build/src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000000fcc2ea7 2. /build/src/Common/ThreadPool.cpp:401: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fcc7f1c 3. /build/src/Common/ThreadPool.cpp:494: ThreadPoolImpl>::scheduleOrThrowOnError(std::function, Priority) @ 0x000000000fcc7a0e 4. /build/src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::spawnThreadsImpl() @ 0x00000000169b2c0c 5. /build/src/Processors/Executors/PipelineExecutor.cpp:394: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x00000000169b0ba7 6. /build/src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x00000000169b03f4 7. /build/src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:se190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169bfeab 8. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc3d92 9. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fcca080 10. ? @ 0x00007fbc6213eac3 11. ? @ 0x00007fbc621d0850 Job's origin stack trace: 0. /build/src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000000fc33b84 1. /build/src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000000fcc2ea7 2. /build/src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fcc535c 3. /build/src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000000fcc584d 4. /build/src/Common/ThreadPool.h:279: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x00000000169bf193 5. /build/src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x00000000169bf518 6. /build/src/Server/TCPHandler.cpp:1237: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x00000000168f1525 7. /build/src/Server/TCPHandler.cpp:678: DB::TCPHandler::runImpl() @ 0x00000000168e68e5 8. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 9. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 10. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 11. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 12. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 13. ? @ 0x00007fbc6213eac3 14. ? @ 0x00007fbc621d0850 2025.07.28 11:57:55.000058 [ 11826 ] {6b3e90a2-5c0b-44fd-86a0-c37f03eb76c7} executeQuery: Code: 219. DB::Exception: New table appeared in database being dropped or detached. Try again. (DATABASE_NOT_EMPTY) (version 25.3.6.10636.altinitytest (altinity build)) (from [::1]:57596) (comment: 02344_distinct_limit_distiributed.sql) (in query: DROP DATABASE IF EXISTS test_e77n07yz SYNC ), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000000a074fcb 4. /build/src/Interpreters/DatabaseCatalog.cpp:608: DB::DatabaseCatalog::detachDatabase(std::shared_ptr, String const&, bool, bool) @ 0x00000000144f41b9 5. /build/src/Interpreters/InterpreterDropQuery.cpp:482: DB::InterpreterDropQuery::executeToDatabaseImpl(DB::ASTDropQuery const&, std::shared_ptr&, std::vector, DB::UUIDTag>, std::allocator, DB::UUIDTag>>>&) @ 0x00000000149179be 6. /build/src/Interpreters/InterpreterDropQuery.cpp:363: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x0000000014913988 7. /build/src/Interpreters/InterpreterDropQuery.cpp:99: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000014913142 8. /build/src/Interpreters/InterpreterDropQuery.cpp:72: DB::InterpreterDropQuery::execute() @ 0x0000000014912b65 9. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88dc9 10. /build/src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x0000000014c8ca7b 11. /build/src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000001686da12 12. /build/src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x0000000016870807 13. /build/src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x0000000016907e99 14. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 15. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 16. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 17. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 18. ? @ 0x00007fbc6213eac3 19. ? @ 0x00007fbc621d0850 2025.07.28 11:57:55.009805 [ 11826 ] {6b3e90a2-5c0b-44fd-86a0-c37f03eb76c7} 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. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000000a074fcb 4. /build/src/Interpreters/DatabaseCatalog.cpp:608: DB::DatabaseCatalog::detachDatabase(std::shared_ptr, String const&, bool, bool) @ 0x00000000144f41b9 5. /build/src/Interpreters/InterpreterDropQuery.cpp:482: DB::InterpreterDropQuery::executeToDatabaseImpl(DB::ASTDropQuery const&, std::shared_ptr&, std::vector, DB::UUIDTag>, std::allocator, DB::UUIDTag>>>&) @ 0x00000000149179be 6. /build/src/Interpreters/InterpreterDropQuery.cpp:363: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x0000000014913988 7. /build/src/Interpreters/InterpreterDropQuery.cpp:99: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000014913142 8. /build/src/Interpreters/InterpreterDropQuery.cpp:72: DB::InterpreterDropQuery::execute() @ 0x0000000014912b65 9. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88dc9 10. /build/src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x0000000014c8ca7b 11. /build/src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000001686da12 12. /build/src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x0000000016870807 13. /build/src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x0000000016907e99 14. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 15. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 16. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 17. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 18. ? @ 0x00007fbc6213eac3 19. ? @ 0x00007fbc621d0850 (version 25.3.6.10636.altinitytest (altinity build)) 2025.07.28 11:57:55.354218 [ 3964 ] {} test_13.rmt2 (7f9b740d-015c-470e-8cc6-8ba33be0dc63): auto DB::StorageReplicatedMergeTree::processQueueEntry(ReplicatedMergeTreeQueue::SelectedEntryPtr)::(anonymous class)::operator()(LogEntryPtr &) const: Code: 86. DB::HTTPException: Received error from remote server http://146b4357c08d:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Ftest%2F01165%2Ftest_13%2Frmt%2Freplicas%2F1&part=20250728_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.6.10636.altinitytest (altinity build)) '. (RECEIVED_ERROR_FROM_REMOTE_IO_SERVER), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.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 const&, int&&, String const&, unsigned long&&, String const&) @ 0x000000000feda8d9 4. /build/src/IO/HTTPCommon.cpp:104: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x000000000feda6e2 5. /build/src/IO/HTTPCommon.cpp:93: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x000000000feda537 6. /build/src/IO/ReadWriteBufferFromHTTP.cpp:277: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x000000001184a4c4 7. /build/src/IO/ReadWriteBufferFromHTTP.cpp:285: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x000000001184a615 8. /build/src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x000000001184ae59 9. /build/src/IO/ReadWriteBufferFromHTTP.cpp:472: void std::__function::__policy_invoker::__call_impl[abi:se190107]>(std::__function::__policy_storage const*) @ 0x000000001184cedd 10. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001184858b 11. /build/src/IO/ReadWriteBufferFromHTTP.cpp:465: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x000000001184bf0b 12. /build/src/IO/ReadBuffer.h:60: DB::ReadBuffer::next() @ 0x000000000a148c7b 13. /build/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) @ 0x0000000011849fb2 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]>&)>&, 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&) @ 0x0000000011841980 15. /build/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) @ 0x000000001621208e 16. /build/src/Storages/StorageReplicatedMergeTree.cpp:5228: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl[abi:se190107] const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000015f9a5fe 17. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000015ed8bfd 18. /build/src/Storages/StorageReplicatedMergeTree.cpp:2514: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x0000000015ec9aab 19. /build/src/Storages/StorageReplicatedMergeTree.cpp:2349: DB::StorageReplicatedMergeTree::executeLogEntry(DB::ReplicatedMergeTreeLogEntry&) @ 0x0000000015eba91b 20. /build/src/Storages/StorageReplicatedMergeTree.cpp:3876: bool std::__function::__policy_invoker&)>::__call_impl[abi:se190107])::$_1, bool (std::shared_ptr&)>>(std::__function::__policy_storage const*, std::shared_ptr&) @ 0x0000000015f9837e 21. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000165d6fc3 22. /build/src/Storages/StorageReplicatedMergeTree.cpp:3872: DB::StorageReplicatedMergeTree::processQueueEntry(std::shared_ptr) @ 0x0000000015efc18a 23. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001624c1b2 24. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000162f9c70 25. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x00000000162fa55a 26. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc6653 27. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000000fccc4c3 28. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc3d92 29. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fcca080 30. ? @ 0x00007fbc6213eac3 31. ? @ 0x00007fbc621d0850 (version 25.3.6.10636.altinitytest (altinity build)) 2025.07.28 11:57:56.145599 [ 11826 ] {f1376e6a-863c-44fd-92b3-70680e7b277a} executeQuery: Code: 46. DB::Exception: Table function 'view' cannot be used as an expression. (UNKNOWN_FUNCTION) (version 25.3.6.10636.altinitytest (altinity build)) (from [::1]:54920) (comment: 01715_table_function_view_fix.sql) (query 1, line 3) (in query: SELECT sumIf(dummy, dummy) FROM remote('127.0.0.{1,2}', numbers(2, 100), view(SELECT CAST(NULL, 'Nullable(UInt8)') AS dummy FROM system.one));), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000a9b78ab 4. /build/src/Parsers/ASTFunction.cpp:39: DB::ASTFunction::appendColumnNameImpl(DB::WriteBuffer&) const @ 0x00000000179ab9a4 5. /build/src/Parsers/IAST.cpp:255: DB::IAST::getColumnName() const @ 0x0000000017a35bb7 6. /build/src/Interpreters/ExpressionAnalyzer.cpp:1859: DB::ExpressionAnalyzer::getActionsDAG(bool, bool) @ 0x0000000014537fd5 7. /build/src/Interpreters/ExpressionAnalyzer.cpp:1902: DB::ExpressionAnalyzer::getActions(bool, bool, DB::CompileExpressions) @ 0x0000000014538609 8. /build/src/Storages/StorageDistributed.cpp:266: DB::(anonymous namespace)::buildShardingKeyExpression(std::shared_ptr const&, std::shared_ptr, DB::NamesAndTypesList const&, bool) @ 0x0000000015d5e6aa 9. /build/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) @ 0x0000000015d5cf4d 10. /build/contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: std::shared_ptr std::allocate_shared[abi:se190107], 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&&) @ 0x0000000011809909 11. /build/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 @ 0x0000000011805a50 12. /build/src/TableFunctions/ITableFunction.cpp:36: DB::ITableFunction::execute(std::shared_ptr const&, std::shared_ptr, String const&, DB::ColumnsDescription, bool, bool) const @ 0x00000000131e9fc3 13. /build/src/Interpreters/Context.cpp:2501: DB::Context::executeTableFunction(std::shared_ptr const&, std::shared_ptr const&) @ 0x00000000144345b2 14. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:4975: DB::QueryAnalyzer::resolveTableFunction(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&, bool) @ 0x000000001401e9f9 15. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5342: DB::QueryAnalyzer::resolveQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&) @ 0x00000000140452bf 16. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5597: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000140136f0 17. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000140127f9 18. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000014011fce 19. /build/src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000001406ce8a 20. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000014973b42 21. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000001497268d 22. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000014974d24 23. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001492924b 24. /build/src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88641 25. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 26. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 27. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 28. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 29. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 30. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 31. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 2025.07.28 11:57:56.151443 [ 11826 ] {} TCPHandler: Code: 46. DB::Exception: Table function 'view' cannot be used as an expression. (UNKNOWN_FUNCTION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000a9b78ab 4. /build/src/Parsers/ASTFunction.cpp:39: DB::ASTFunction::appendColumnNameImpl(DB::WriteBuffer&) const @ 0x00000000179ab9a4 5. /build/src/Parsers/IAST.cpp:255: DB::IAST::getColumnName() const @ 0x0000000017a35bb7 6. /build/src/Interpreters/ExpressionAnalyzer.cpp:1859: DB::ExpressionAnalyzer::getActionsDAG(bool, bool) @ 0x0000000014537fd5 7. /build/src/Interpreters/ExpressionAnalyzer.cpp:1902: DB::ExpressionAnalyzer::getActions(bool, bool, DB::CompileExpressions) @ 0x0000000014538609 8. /build/src/Storages/StorageDistributed.cpp:266: DB::(anonymous namespace)::buildShardingKeyExpression(std::shared_ptr const&, std::shared_ptr, DB::NamesAndTypesList const&, bool) @ 0x0000000015d5e6aa 9. /build/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) @ 0x0000000015d5cf4d 10. /build/contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: std::shared_ptr std::allocate_shared[abi:se190107], 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&&) @ 0x0000000011809909 11. /build/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 @ 0x0000000011805a50 12. /build/src/TableFunctions/ITableFunction.cpp:36: DB::ITableFunction::execute(std::shared_ptr const&, std::shared_ptr, String const&, DB::ColumnsDescription, bool, bool) const @ 0x00000000131e9fc3 13. /build/src/Interpreters/Context.cpp:2501: DB::Context::executeTableFunction(std::shared_ptr const&, std::shared_ptr const&) @ 0x00000000144345b2 14. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:4975: DB::QueryAnalyzer::resolveTableFunction(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&, bool) @ 0x000000001401e9f9 15. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5342: DB::QueryAnalyzer::resolveQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&) @ 0x00000000140452bf 16. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5597: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000140136f0 17. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000140127f9 18. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000014011fce 19. /build/src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000001406ce8a 20. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000014973b42 21. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000001497268d 22. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000014974d24 23. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001492924b 24. /build/src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88641 25. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 26. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 27. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 28. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 29. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 30. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 31. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 2025.07.28 11:57:56.181821 [ 3974 ] {} test_13.rmt2 (7f9b740d-015c-470e-8cc6-8ba33be0dc63): auto DB::StorageReplicatedMergeTree::processQueueEntry(ReplicatedMergeTreeQueue::SelectedEntryPtr)::(anonymous class)::operator()(LogEntryPtr &) const: Code: 86. DB::HTTPException: Received error from remote server http://146b4357c08d:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Ftest%2F01165%2Ftest_13%2Frmt%2Freplicas%2F1&part=20250728_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.6.10636.altinitytest (altinity build)) '. (RECEIVED_ERROR_FROM_REMOTE_IO_SERVER), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.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 const&, int&&, String const&, unsigned long&&, String const&) @ 0x000000000feda8d9 4. /build/src/IO/HTTPCommon.cpp:104: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x000000000feda6e2 5. /build/src/IO/HTTPCommon.cpp:93: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x000000000feda537 6. /build/src/IO/ReadWriteBufferFromHTTP.cpp:277: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x000000001184a4c4 7. /build/src/IO/ReadWriteBufferFromHTTP.cpp:285: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x000000001184a615 8. /build/src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x000000001184ae59 9. /build/src/IO/ReadWriteBufferFromHTTP.cpp:472: void std::__function::__policy_invoker::__call_impl[abi:se190107]>(std::__function::__policy_storage const*) @ 0x000000001184cedd 10. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001184858b 11. /build/src/IO/ReadWriteBufferFromHTTP.cpp:465: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x000000001184bf0b 12. /build/src/IO/ReadBuffer.h:60: DB::ReadBuffer::next() @ 0x000000000a148c7b 13. /build/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) @ 0x0000000011849fb2 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]>&)>&, 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&) @ 0x0000000011841980 15. /build/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) @ 0x000000001621208e 16. /build/src/Storages/StorageReplicatedMergeTree.cpp:5228: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl[abi:se190107] const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000015f9a5fe 17. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000015ed8bfd 18. /build/src/Storages/StorageReplicatedMergeTree.cpp:2514: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x0000000015ec9aab 19. /build/src/Storages/StorageReplicatedMergeTree.cpp:2349: DB::StorageReplicatedMergeTree::executeLogEntry(DB::ReplicatedMergeTreeLogEntry&) @ 0x0000000015eba91b 20. /build/src/Storages/StorageReplicatedMergeTree.cpp:3876: bool std::__function::__policy_invoker&)>::__call_impl[abi:se190107])::$_1, bool (std::shared_ptr&)>>(std::__function::__policy_storage const*, std::shared_ptr&) @ 0x0000000015f9837e 21. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000165d6fc3 22. /build/src/Storages/StorageReplicatedMergeTree.cpp:3872: DB::StorageReplicatedMergeTree::processQueueEntry(std::shared_ptr) @ 0x0000000015efc18a 23. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001624c1b2 24. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000162f9c70 25. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x00000000162fa55a 26. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc6653 27. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000000fccc4c3 28. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc3d92 29. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fcca080 30. ? @ 0x00007fbc6213eac3 31. ? @ 0x00007fbc621d0850 (version 25.3.6.10636.altinitytest (altinity build)) 2025.07.28 11:57:57.281199 [ 3961 ] {} test_13.rmt2 (7f9b740d-015c-470e-8cc6-8ba33be0dc63): auto DB::StorageReplicatedMergeTree::processQueueEntry(ReplicatedMergeTreeQueue::SelectedEntryPtr)::(anonymous class)::operator()(LogEntryPtr &) const: Code: 86. DB::HTTPException: Received error from remote server http://146b4357c08d:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Ftest%2F01165%2Ftest_13%2Frmt%2Freplicas%2F1&part=20250728_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.6.10636.altinitytest (altinity build)) '. (RECEIVED_ERROR_FROM_REMOTE_IO_SERVER), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.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 const&, int&&, String const&, unsigned long&&, String const&) @ 0x000000000feda8d9 4. /build/src/IO/HTTPCommon.cpp:104: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x000000000feda6e2 5. /build/src/IO/HTTPCommon.cpp:93: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x000000000feda537 6. /build/src/IO/ReadWriteBufferFromHTTP.cpp:277: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x000000001184a4c4 7. /build/src/IO/ReadWriteBufferFromHTTP.cpp:285: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x000000001184a615 8. /build/src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x000000001184ae59 9. /build/src/IO/ReadWriteBufferFromHTTP.cpp:472: void std::__function::__policy_invoker::__call_impl[abi:se190107]>(std::__function::__policy_storage const*) @ 0x000000001184cedd 10. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001184858b 11. /build/src/IO/ReadWriteBufferFromHTTP.cpp:465: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x000000001184bf0b 12. /build/src/IO/ReadBuffer.h:60: DB::ReadBuffer::next() @ 0x000000000a148c7b 13. /build/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) @ 0x0000000011849fb2 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]>&)>&, 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&) @ 0x0000000011841980 15. /build/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) @ 0x000000001621208e 16. /build/src/Storages/StorageReplicatedMergeTree.cpp:5228: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl[abi:se190107] const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000015f9a5fe 17. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000015ed8bfd 18. /build/src/Storages/StorageReplicatedMergeTree.cpp:2514: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x0000000015ec9aab 19. /build/src/Storages/StorageReplicatedMergeTree.cpp:2349: DB::StorageReplicatedMergeTree::executeLogEntry(DB::ReplicatedMergeTreeLogEntry&) @ 0x0000000015eba91b 20. /build/src/Storages/StorageReplicatedMergeTree.cpp:3876: bool std::__function::__policy_invoker&)>::__call_impl[abi:se190107])::$_1, bool (std::shared_ptr&)>>(std::__function::__policy_storage const*, std::shared_ptr&) @ 0x0000000015f9837e 21. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000165d6fc3 22. /build/src/Storages/StorageReplicatedMergeTree.cpp:3872: DB::StorageReplicatedMergeTree::processQueueEntry(std::shared_ptr) @ 0x0000000015efc18a 23. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001624c1b2 24. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000162f9c70 25. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x00000000162fa55a 26. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc6653 27. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000000fccc4c3 28. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc3d92 29. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fcca080 30. ? @ 0x00007fbc6213eac3 31. ? @ 0x00007fbc621d0850 (version 25.3.6.10636.altinitytest (altinity build)) 2025.07.28 11:57:57.437257 [ 3970 ] {} test_13.rmt2 (7f9b740d-015c-470e-8cc6-8ba33be0dc63): auto DB::StorageReplicatedMergeTree::processQueueEntry(ReplicatedMergeTreeQueue::SelectedEntryPtr)::(anonymous class)::operator()(LogEntryPtr &) const: Code: 86. DB::HTTPException: Received error from remote server http://146b4357c08d:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Ftest%2F01165%2Ftest_13%2Frmt%2Freplicas%2F1&part=20250728_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.6.10636.altinitytest (altinity build)) '. (RECEIVED_ERROR_FROM_REMOTE_IO_SERVER), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.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 const&, int&&, String const&, unsigned long&&, String const&) @ 0x000000000feda8d9 4. /build/src/IO/HTTPCommon.cpp:104: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x000000000feda6e2 5. /build/src/IO/HTTPCommon.cpp:93: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x000000000feda537 6. /build/src/IO/ReadWriteBufferFromHTTP.cpp:277: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x000000001184a4c4 7. /build/src/IO/ReadWriteBufferFromHTTP.cpp:285: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x000000001184a615 8. /build/src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x000000001184ae59 9. /build/src/IO/ReadWriteBufferFromHTTP.cpp:472: void std::__function::__policy_invoker::__call_impl[abi:se190107]>(std::__function::__policy_storage const*) @ 0x000000001184cedd 10. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001184858b 11. /build/src/IO/ReadWriteBufferFromHTTP.cpp:465: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x000000001184bf0b 12. /build/src/IO/ReadBuffer.h:60: DB::ReadBuffer::next() @ 0x000000000a148c7b 13. /build/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) @ 0x0000000011849fb2 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]>&)>&, 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&) @ 0x0000000011841980 15. /build/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) @ 0x000000001621208e 16. /build/src/Storages/StorageReplicatedMergeTree.cpp:5228: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl[abi:se190107] const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000015f9a5fe 17. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000015ed8bfd 18. /build/src/Storages/StorageReplicatedMergeTree.cpp:2514: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x0000000015ec9aab 19. /build/src/Storages/StorageReplicatedMergeTree.cpp:2349: DB::StorageReplicatedMergeTree::executeLogEntry(DB::ReplicatedMergeTreeLogEntry&) @ 0x0000000015eba91b 20. /build/src/Storages/StorageReplicatedMergeTree.cpp:3876: bool std::__function::__policy_invoker&)>::__call_impl[abi:se190107])::$_1, bool (std::shared_ptr&)>>(std::__function::__policy_storage const*, std::shared_ptr&) @ 0x0000000015f9837e 21. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000165d6fc3 22. /build/src/Storages/StorageReplicatedMergeTree.cpp:3872: DB::StorageReplicatedMergeTree::processQueueEntry(std::shared_ptr) @ 0x0000000015efc18a 23. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001624c1b2 24. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000162f9c70 25. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x00000000162fa55a 26. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc6653 27. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000000fccc4c3 28. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc3d92 29. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fcca080 30. ? @ 0x00007fbc6213eac3 31. ? @ 0x00007fbc621d0850 (version 25.3.6.10636.altinitytest (altinity build)) 2025.07.28 11:57:58.132817 [ 3968 ] {} test_13.rmt2 (7f9b740d-015c-470e-8cc6-8ba33be0dc63): auto DB::StorageReplicatedMergeTree::processQueueEntry(ReplicatedMergeTreeQueue::SelectedEntryPtr)::(anonymous class)::operator()(LogEntryPtr &) const: Code: 86. DB::HTTPException: Received error from remote server http://146b4357c08d:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Ftest%2F01165%2Ftest_13%2Frmt%2Freplicas%2F1&part=20250728_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.6.10636.altinitytest (altinity build)) '. (RECEIVED_ERROR_FROM_REMOTE_IO_SERVER), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.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 const&, int&&, String const&, unsigned long&&, String const&) @ 0x000000000feda8d9 4. /build/src/IO/HTTPCommon.cpp:104: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x000000000feda6e2 5. /build/src/IO/HTTPCommon.cpp:93: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x000000000feda537 6. /build/src/IO/ReadWriteBufferFromHTTP.cpp:277: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x000000001184a4c4 7. /build/src/IO/ReadWriteBufferFromHTTP.cpp:285: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x000000001184a615 8. /build/src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x000000001184ae59 9. /build/src/IO/ReadWriteBufferFromHTTP.cpp:472: void std::__function::__policy_invoker::__call_impl[abi:se190107]>(std::__function::__policy_storage const*) @ 0x000000001184cedd 10. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001184858b 11. /build/src/IO/ReadWriteBufferFromHTTP.cpp:465: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x000000001184bf0b 12. /build/src/IO/ReadBuffer.h:60: DB::ReadBuffer::next() @ 0x000000000a148c7b 13. /build/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) @ 0x0000000011849fb2 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]>&)>&, 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&) @ 0x0000000011841980 15. /build/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) @ 0x000000001621208e 16. /build/src/Storages/StorageReplicatedMergeTree.cpp:5228: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl[abi:se190107] const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000015f9a5fe 17. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000015ed8bfd 18. /build/src/Storages/StorageReplicatedMergeTree.cpp:2514: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x0000000015ec9aab 19. /build/src/Storages/StorageReplicatedMergeTree.cpp:2349: DB::StorageReplicatedMergeTree::executeLogEntry(DB::ReplicatedMergeTreeLogEntry&) @ 0x0000000015eba91b 20. /build/src/Storages/StorageReplicatedMergeTree.cpp:3876: bool std::__function::__policy_invoker&)>::__call_impl[abi:se190107])::$_1, bool (std::shared_ptr&)>>(std::__function::__policy_storage const*, std::shared_ptr&) @ 0x0000000015f9837e 21. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000165d6fc3 22. /build/src/Storages/StorageReplicatedMergeTree.cpp:3872: DB::StorageReplicatedMergeTree::processQueueEntry(std::shared_ptr) @ 0x0000000015efc18a 23. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001624c1b2 24. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000162f9c70 25. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x00000000162fa55a 26. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc6653 27. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000000fccc4c3 28. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc3d92 29. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fcca080 30. ? @ 0x00007fbc6213eac3 31. ? @ 0x00007fbc621d0850 (version 25.3.6.10636.altinitytest (altinity build)) 2025.07.28 11:57:58.883879 [ 3965 ] {} test_13.rmt2 (7f9b740d-015c-470e-8cc6-8ba33be0dc63): auto DB::StorageReplicatedMergeTree::processQueueEntry(ReplicatedMergeTreeQueue::SelectedEntryPtr)::(anonymous class)::operator()(LogEntryPtr &) const: Code: 86. DB::HTTPException: Received error from remote server http://146b4357c08d:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Ftest%2F01165%2Ftest_13%2Frmt%2Freplicas%2F1&part=20250728_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.6.10636.altinitytest (altinity build)) '. (RECEIVED_ERROR_FROM_REMOTE_IO_SERVER), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.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 const&, int&&, String const&, unsigned long&&, String const&) @ 0x000000000feda8d9 4. /build/src/IO/HTTPCommon.cpp:104: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x000000000feda6e2 5. /build/src/IO/HTTPCommon.cpp:93: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x000000000feda537 6. /build/src/IO/ReadWriteBufferFromHTTP.cpp:277: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x000000001184a4c4 7. /build/src/IO/ReadWriteBufferFromHTTP.cpp:285: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x000000001184a615 8. /build/src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x000000001184ae59 9. /build/src/IO/ReadWriteBufferFromHTTP.cpp:472: void std::__function::__policy_invoker::__call_impl[abi:se190107]>(std::__function::__policy_storage const*) @ 0x000000001184cedd 10. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001184858b 11. /build/src/IO/ReadWriteBufferFromHTTP.cpp:465: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x000000001184bf0b 12. /build/src/IO/ReadBuffer.h:60: DB::ReadBuffer::next() @ 0x000000000a148c7b 13. /build/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) @ 0x0000000011849fb2 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]>&)>&, 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&) @ 0x0000000011841980 15. /build/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) @ 0x000000001621208e 16. /build/src/Storages/StorageReplicatedMergeTree.cpp:5228: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl[abi:se190107] const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000015f9a5fe 17. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000015ed8bfd 18. /build/src/Storages/StorageReplicatedMergeTree.cpp:2514: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x0000000015ec9aab 19. /build/src/Storages/StorageReplicatedMergeTree.cpp:2349: DB::StorageReplicatedMergeTree::executeLogEntry(DB::ReplicatedMergeTreeLogEntry&) @ 0x0000000015eba91b 20. /build/src/Storages/StorageReplicatedMergeTree.cpp:3876: bool std::__function::__policy_invoker&)>::__call_impl[abi:se190107])::$_1, bool (std::shared_ptr&)>>(std::__function::__policy_storage const*, std::shared_ptr&) @ 0x0000000015f9837e 21. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000165d6fc3 22. /build/src/Storages/StorageReplicatedMergeTree.cpp:3872: DB::StorageReplicatedMergeTree::processQueueEntry(std::shared_ptr) @ 0x0000000015efc18a 23. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001624c1b2 24. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000162f9c70 25. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x00000000162fa55a 26. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc6653 27. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000000fccc4c3 28. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc3d92 29. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fcca080 30. ? @ 0x00007fbc6213eac3 31. ? @ 0x00007fbc621d0850 (version 25.3.6.10636.altinitytest (altinity build)) 2025.07.28 11:57:59.129133 [ 17207 ] {d634f625-ce72-4c4d-b853-e8e8d0db3f76} executeQuery: Code: 452. DB::Exception: Setting allow_experimental_object_type should not be changed. (SETTING_CONSTRAINT_VIOLATION) (version 25.3.6.10636.altinitytest (altinity build)) (from [::1]:55186) (comment: 01825_type_json_field.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. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x000000000c25bc4b 4. /build/src/Access/SettingsConstraints.cpp:343: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000138596e3 5. /build/src/Access/SettingsConstraints.cpp:300: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000013858faf 6. /build/src/Access/SettingsConstraints.cpp:194: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges const&, DB::SettingSource) const @ 0x00000000138591b3 7. /build/src/Interpreters/Context.cpp:2722: DB::Context::checkSettingsConstraints(DB::SettingsChanges const&, DB::SettingSource) @ 0x0000000014436509 8. /build/src/Interpreters/InterpreterSetQuery.cpp:28: DB::InterpreterSetQuery::execute() @ 0x00000000149e240a 9. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88dc9 10. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 11. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 12. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 13. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 14. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 16. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 17. ? @ 0x00007fbc6213eac3 18. ? @ 0x00007fbc621d0850 2025.07.28 11:57:59.138850 [ 17207 ] {} 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. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x000000000c25bc4b 4. /build/src/Access/SettingsConstraints.cpp:343: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000138596e3 5. /build/src/Access/SettingsConstraints.cpp:300: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000013858faf 6. /build/src/Access/SettingsConstraints.cpp:194: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges const&, DB::SettingSource) const @ 0x00000000138591b3 7. /build/src/Interpreters/Context.cpp:2722: DB::Context::checkSettingsConstraints(DB::SettingsChanges const&, DB::SettingSource) @ 0x0000000014436509 8. /build/src/Interpreters/InterpreterSetQuery.cpp:28: DB::InterpreterSetQuery::execute() @ 0x00000000149e240a 9. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88dc9 10. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 11. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 12. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 13. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 14. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 16. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 17. ? @ 0x00007fbc6213eac3 18. ? @ 0x00007fbc621d0850 2025.07.28 11:57:59.258879 [ 3977 ] {} test_13.rmt2 (7f9b740d-015c-470e-8cc6-8ba33be0dc63): auto DB::StorageReplicatedMergeTree::processQueueEntry(ReplicatedMergeTreeQueue::SelectedEntryPtr)::(anonymous class)::operator()(LogEntryPtr &) const: Code: 86. DB::HTTPException: Received error from remote server http://146b4357c08d:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Ftest%2F01165%2Ftest_13%2Frmt%2Freplicas%2F1&part=20250728_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.6.10636.altinitytest (altinity build)) '. (RECEIVED_ERROR_FROM_REMOTE_IO_SERVER), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.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 const&, int&&, String const&, unsigned long&&, String const&) @ 0x000000000feda8d9 4. /build/src/IO/HTTPCommon.cpp:104: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x000000000feda6e2 5. /build/src/IO/HTTPCommon.cpp:93: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x000000000feda537 6. /build/src/IO/ReadWriteBufferFromHTTP.cpp:277: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x000000001184a4c4 7. /build/src/IO/ReadWriteBufferFromHTTP.cpp:285: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x000000001184a615 8. /build/src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x000000001184ae59 9. /build/src/IO/ReadWriteBufferFromHTTP.cpp:472: void std::__function::__policy_invoker::__call_impl[abi:se190107]>(std::__function::__policy_storage const*) @ 0x000000001184cedd 10. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001184858b 11. /build/src/IO/ReadWriteBufferFromHTTP.cpp:465: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x000000001184bf0b 12. /build/src/IO/ReadBuffer.h:60: DB::ReadBuffer::next() @ 0x000000000a148c7b 13. /build/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) @ 0x0000000011849fb2 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]>&)>&, 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&) @ 0x0000000011841980 15. /build/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) @ 0x000000001621208e 16. /build/src/Storages/StorageReplicatedMergeTree.cpp:5228: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl[abi:se190107] const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000015f9a5fe 17. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000015ed8bfd 18. /build/src/Storages/StorageReplicatedMergeTree.cpp:2514: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x0000000015ec9aab 19. /build/src/Storages/StorageReplicatedMergeTree.cpp:2349: DB::StorageReplicatedMergeTree::executeLogEntry(DB::ReplicatedMergeTreeLogEntry&) @ 0x0000000015eba91b 20. /build/src/Storages/StorageReplicatedMergeTree.cpp:3876: bool std::__function::__policy_invoker&)>::__call_impl[abi:se190107])::$_1, bool (std::shared_ptr&)>>(std::__function::__policy_storage const*, std::shared_ptr&) @ 0x0000000015f9837e 21. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000165d6fc3 22. /build/src/Storages/StorageReplicatedMergeTree.cpp:3872: DB::StorageReplicatedMergeTree::processQueueEntry(std::shared_ptr) @ 0x0000000015efc18a 23. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001624c1b2 24. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000162f9c70 25. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x00000000162fa55a 26. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc6653 27. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000000fccc4c3 28. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc3d92 29. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fcca080 30. ? @ 0x00007fbc6213eac3 31. ? @ 0x00007fbc621d0850 (version 25.3.6.10636.altinitytest (altinity build)) 2025.07.28 11:57:59.359942 [ 7630 ] {a8c55b7b-c76e-46da-a85f-fcaf63bb03b5} executeQuery: Code: 36. DB::Exception: Bidirectional can only be applied to hierarchical attributes. (BAD_ARGUMENTS) (version 25.3.6.10636.altinitytest (altinity build)) (from [::1]:55144) (comment: 02294_dictionaries_hierarchical_index.sql) (query 5, line 11) (in query: CREATE DICTIONARY hierarchy_flat_dictionary_index ( id UInt64, parent_id UInt64 BIDIRECTIONAL ) PRIMARY KEY id SOURCE(CLICKHOUSE(TABLE 'test_hierarchy_source_table')) LAYOUT(FLAT()) LIFETIME(0);), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000000a074fcb 4. /build/src/Dictionaries/DictionaryStructure.cpp:365: DB::DictionaryStructure::getAttributes(Poco::Util::AbstractConfiguration const&, String const&, bool) @ 0x0000000012d900a0 5. /build/src/Dictionaries/DictionaryStructure.cpp:97: DB::DictionaryStructure::DictionaryStructure(Poco::Util::AbstractConfiguration const&, String const&) @ 0x0000000012d8d9c8 6. /build/src/Interpreters/ExternalDictionariesLoader.cpp:214: DB::ExternalDictionariesLoader::getDictionaryStructure(Poco::Util::AbstractConfiguration const&, String const&) @ 0x00000000148a8f49 7. /build/src/Storages/StorageDictionary.cpp:143: DB::StorageDictionary::StorageDictionary(DB::StorageID const&, Poco::AutoPtr, std::shared_ptr) @ 0x0000000015d5792f 8. /build/contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: std::shared_ptr std::allocate_shared[abi:se190107], DB::StorageID&, Poco::AutoPtr&, std::shared_ptr&, 0>(std::allocator const&, DB::StorageID&, Poco::AutoPtr&, std::shared_ptr&) @ 0x0000000015d5b169 9. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:851: std::shared_ptr std::__function::__policy_invoker (DB::StorageFactory::Arguments const&)>::__call_impl[abi:se190107] (DB::StorageFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::StorageFactory::Arguments const&) @ 0x0000000015d5a680 10. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000015d81ea2 11. /build/src/Interpreters/InterpreterCreateQuery.cpp:1945: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x00000000149009bb 12. /build/src/Interpreters/InterpreterCreateQuery.cpp:1743: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000148f9aa9 13. /build/src/Interpreters/InterpreterCreateQuery.cpp:2352: DB::InterpreterCreateQuery::execute() @ 0x0000000014905a41 14. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88dc9 15. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 16. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 17. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 18. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 19. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 20. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 21. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 22. ? @ 0x00007fbc6213eac3 23. ? @ 0x00007fbc621d0850 2025.07.28 11:57:59.366365 [ 7630 ] {} TCPHandler: Code: 36. DB::Exception: Bidirectional can only be applied to hierarchical attributes. (BAD_ARGUMENTS), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000000a074fcb 4. /build/src/Dictionaries/DictionaryStructure.cpp:365: DB::DictionaryStructure::getAttributes(Poco::Util::AbstractConfiguration const&, String const&, bool) @ 0x0000000012d900a0 5. /build/src/Dictionaries/DictionaryStructure.cpp:97: DB::DictionaryStructure::DictionaryStructure(Poco::Util::AbstractConfiguration const&, String const&) @ 0x0000000012d8d9c8 6. /build/src/Interpreters/ExternalDictionariesLoader.cpp:214: DB::ExternalDictionariesLoader::getDictionaryStructure(Poco::Util::AbstractConfiguration const&, String const&) @ 0x00000000148a8f49 7. /build/src/Storages/StorageDictionary.cpp:143: DB::StorageDictionary::StorageDictionary(DB::StorageID const&, Poco::AutoPtr, std::shared_ptr) @ 0x0000000015d5792f 8. /build/contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: std::shared_ptr std::allocate_shared[abi:se190107], DB::StorageID&, Poco::AutoPtr&, std::shared_ptr&, 0>(std::allocator const&, DB::StorageID&, Poco::AutoPtr&, std::shared_ptr&) @ 0x0000000015d5b169 9. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:851: std::shared_ptr std::__function::__policy_invoker (DB::StorageFactory::Arguments const&)>::__call_impl[abi:se190107] (DB::StorageFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::StorageFactory::Arguments const&) @ 0x0000000015d5a680 10. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000015d81ea2 11. /build/src/Interpreters/InterpreterCreateQuery.cpp:1945: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x00000000149009bb 12. /build/src/Interpreters/InterpreterCreateQuery.cpp:1743: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000148f9aa9 13. /build/src/Interpreters/InterpreterCreateQuery.cpp:2352: DB::InterpreterCreateQuery::execute() @ 0x0000000014905a41 14. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88dc9 15. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 16. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 17. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 18. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 19. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 20. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 21. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 22. ? @ 0x00007fbc6213eac3 23. ? @ 0x00007fbc621d0850 2025.07.28 11:57:59.576914 [ 17207 ] {f373590d-1a5e-4d13-85aa-f95aee3a750f} 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.6.10636.altinitytest (altinity build)) (from [::1]:55200) (comment: 00502_custom_partitioning_replicated_zookeeper_long.sql) (query 6, line 11) (in query: CREATE TABLE not_partitioned_replica1_00502 (`x` UInt8) ENGINE = ReplicatedMergeTree('/clickhouse/tables/{database}/test/not_partitioned_00502', '1') ORDER BY x SETTINGS index_granularity = 42608, 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 = 418786428, compact_parts_max_bytes_to_buffer = 183867066, compact_parts_max_granules_to_buffer = 256, compact_parts_merge_max_bytes_to_prefetch_part = 24253581, merge_max_block_size = 20869, 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 = 83, min_merge_bytes_to_use_direct_io = 10737418240, index_granularity_bytes = 9555608, 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 = false, cache_populated_by_fetch = true, marks_compress_block_size = 83009, primary_key_compress_block_size = 37477, 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. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000000a074fcb 4. /build/src/Databases/DatabaseReplicated.cpp:959: DB::DatabaseReplicated::checkTableEngine(DB::ASTCreateQuery const&, DB::ASTStorage&, std::shared_ptr) const @ 0x0000000013d9cf56 5. /build/src/Databases/DatabaseReplicated.cpp:1083: DB::DatabaseReplicated::checkQueryValid(std::shared_ptr const&, std::shared_ptr) const @ 0x0000000013d9ebb5 6. /build/src/Databases/DatabaseReplicated.cpp:1130: DB::DatabaseReplicated::tryEnqueueReplicatedDDL(std::shared_ptr const&, std::shared_ptr, DB::QueryFlags) @ 0x0000000013d9f10b 7. /build/src/Interpreters/InterpreterCreateQuery.cpp:1723: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000148f96f8 8. /build/src/Interpreters/InterpreterCreateQuery.cpp:2352: DB::InterpreterCreateQuery::execute() @ 0x0000000014905a41 9. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88dc9 10. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 11. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 12. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 13. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 14. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 16. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 17. ? @ 0x00007fbc6213eac3 18. ? @ 0x00007fbc621d0850 2025.07.28 11:57:59.595822 [ 17207 ] {} 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. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000000a074fcb 4. /build/src/Databases/DatabaseReplicated.cpp:959: DB::DatabaseReplicated::checkTableEngine(DB::ASTCreateQuery const&, DB::ASTStorage&, std::shared_ptr) const @ 0x0000000013d9cf56 5. /build/src/Databases/DatabaseReplicated.cpp:1083: DB::DatabaseReplicated::checkQueryValid(std::shared_ptr const&, std::shared_ptr) const @ 0x0000000013d9ebb5 6. /build/src/Databases/DatabaseReplicated.cpp:1130: DB::DatabaseReplicated::tryEnqueueReplicatedDDL(std::shared_ptr const&, std::shared_ptr, DB::QueryFlags) @ 0x0000000013d9f10b 7. /build/src/Interpreters/InterpreterCreateQuery.cpp:1723: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000148f96f8 8. /build/src/Interpreters/InterpreterCreateQuery.cpp:2352: DB::InterpreterCreateQuery::execute() @ 0x0000000014905a41 9. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88dc9 10. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 11. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 12. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 13. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 14. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 16. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 17. ? @ 0x00007fbc6213eac3 18. ? @ 0x00007fbc621d0850 2025.07.28 11:57:59.753114 [ 3967 ] {} test_13.rmt2 (7f9b740d-015c-470e-8cc6-8ba33be0dc63): auto DB::StorageReplicatedMergeTree::processQueueEntry(ReplicatedMergeTreeQueue::SelectedEntryPtr)::(anonymous class)::operator()(LogEntryPtr &) const: Code: 86. DB::HTTPException: Received error from remote server http://146b4357c08d:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Ftest%2F01165%2Ftest_13%2Frmt%2Freplicas%2F1&part=20250728_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.6.10636.altinitytest (altinity build)) '. (RECEIVED_ERROR_FROM_REMOTE_IO_SERVER), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.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 const&, int&&, String const&, unsigned long&&, String const&) @ 0x000000000feda8d9 4. /build/src/IO/HTTPCommon.cpp:104: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x000000000feda6e2 5. /build/src/IO/HTTPCommon.cpp:93: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x000000000feda537 6. /build/src/IO/ReadWriteBufferFromHTTP.cpp:277: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x000000001184a4c4 7. /build/src/IO/ReadWriteBufferFromHTTP.cpp:285: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x000000001184a615 8. /build/src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x000000001184ae59 9. /build/src/IO/ReadWriteBufferFromHTTP.cpp:472: void std::__function::__policy_invoker::__call_impl[abi:se190107]>(std::__function::__policy_storage const*) @ 0x000000001184cedd 10. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001184858b 11. /build/src/IO/ReadWriteBufferFromHTTP.cpp:465: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x000000001184bf0b 12. /build/src/IO/ReadBuffer.h:60: DB::ReadBuffer::next() @ 0x000000000a148c7b 13. /build/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) @ 0x0000000011849fb2 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]>&)>&, 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&) @ 0x0000000011841980 15. /build/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) @ 0x000000001621208e 16. /build/src/Storages/StorageReplicatedMergeTree.cpp:5228: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl[abi:se190107] const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000015f9a5fe 17. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000015ed8bfd 18. /build/src/Storages/StorageReplicatedMergeTree.cpp:2514: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x0000000015ec9aab 19. /build/src/Storages/StorageReplicatedMergeTree.cpp:2349: DB::StorageReplicatedMergeTree::executeLogEntry(DB::ReplicatedMergeTreeLogEntry&) @ 0x0000000015eba91b 20. /build/src/Storages/StorageReplicatedMergeTree.cpp:3876: bool std::__function::__policy_invoker&)>::__call_impl[abi:se190107])::$_1, bool (std::shared_ptr&)>>(std::__function::__policy_storage const*, std::shared_ptr&) @ 0x0000000015f9837e 21. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000165d6fc3 22. /build/src/Storages/StorageReplicatedMergeTree.cpp:3872: DB::StorageReplicatedMergeTree::processQueueEntry(std::shared_ptr) @ 0x0000000015efc18a 23. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001624c1b2 24. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000162f9c70 25. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x00000000162fa55a 26. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc6653 27. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000000fccc4c3 28. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc3d92 29. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fcca080 30. ? @ 0x00007fbc6213eac3 31. ? @ 0x00007fbc621d0850 (version 25.3.6.10636.altinitytest (altinity build)) 2025.07.28 11:57:59.965874 [ 17207 ] {213357e6-81fc-4e77-98db-ce9377ec266d} executeQuery: Code: 439. DB::Exception: Cannot schedule a task: failed to start the thread (threads=1, jobs=1). (CANNOT_SCHEDULE_TASK) (version 25.3.6.10636.altinitytest (altinity build)) (from [::1]:55226) (comment: 01936_empty_function_support_uuid.sql) (query 3, line 3) (in query: SELECT uniqIf(uuid, empty(uuid)), uniqIf(uuid, notEmpty(uuid)) FROM ( SELECT toUUID('00000000-0000-0000-0000-000000000002') AS uuid UNION ALL SELECT toUUID('00000000-0000-0000-0000-000000000000') AS uuid UNION ALL SELECT toUUID('00000000-0000-0000-0000-000000000001') AS uuid );), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000fccaeeb 4. /build/src/Common/ThreadPool.cpp:275: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000fccc813 5. /build/src/Common/ThreadPool.cpp:308: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fcc8286 6. /build/src/Common/ThreadPool.cpp:494: ThreadPoolImpl>::scheduleOrThrowOnError(std::function, Priority) @ 0x000000000fcc7a0e 7. /build/src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::spawnThreadsImpl() @ 0x00000000169b2c0c 8. /build/src/Processors/Executors/PipelineExecutor.cpp:394: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x00000000169b0ba7 9. /build/src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x00000000169b03f4 10. /build/src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:se190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169bfeab 11. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc3d92 12. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fcca080 13. ? @ 0x00007fbc6213eac3 14. ? @ 0x00007fbc621d0850 2025.07.28 11:57:59.977010 [ 17207 ] {} 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. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000fccaeeb 4. /build/src/Common/ThreadPool.cpp:275: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000fccc813 5. /build/src/Common/ThreadPool.cpp:308: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fcc8286 6. /build/src/Common/ThreadPool.cpp:494: ThreadPoolImpl>::scheduleOrThrowOnError(std::function, Priority) @ 0x000000000fcc7a0e 7. /build/src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::spawnThreadsImpl() @ 0x00000000169b2c0c 8. /build/src/Processors/Executors/PipelineExecutor.cpp:394: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x00000000169b0ba7 9. /build/src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x00000000169b03f4 10. /build/src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:se190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169bfeab 11. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc3d92 12. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fcca080 13. ? @ 0x00007fbc6213eac3 14. ? @ 0x00007fbc621d0850 Job's origin stack trace: 0. /build/src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000000fc33b84 1. /build/src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000000fcc2ea7 2. /build/src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fcc535c 3. /build/src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000000fcc584d 4. /build/src/Common/ThreadPool.h:279: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x00000000169bf193 5. /build/src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x00000000169bf518 6. /build/src/Server/TCPHandler.cpp:1237: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x00000000168f1525 7. /build/src/Server/TCPHandler.cpp:678: DB::TCPHandler::runImpl() @ 0x00000000168e68e5 8. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 9. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 10. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 11. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 12. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 13. ? @ 0x00007fbc6213eac3 14. ? @ 0x00007fbc621d0850 2025.07.28 11:58:00.183268 [ 17557 ] {345a7281-62e4-4f1e-a4c7-43f9ef5563ca} executeQuery: Code: 159. DB::Exception: Timeout exceeded: elapsed 60018.922254 ms, maximum: 60000 ms. (TIMEOUT_EXCEEDED) (version 25.3.6.10636.altinitytest (altinity build)) (from [::1]:37424) (comment: 00284_external_aggregation.sql) (query 7, line 13) (in query: SELECT sum(k), sum(c), max(u) FROM (SELECT number AS k, count() AS c, uniqArray(range(number % 16)) AS u FROM (SELECT * FROM system.numbers LIMIT 1000000) GROUP BY k);), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, double&&, long&&) @ 0x0000000013bb358b 4. /build/src/QueryPipeline/ExecutionSpeedLimits.cpp:113: DB::ExecutionSpeedLimits::checkTimeLimit(unsigned long const&, DB::OverflowMode) const @ 0x0000000013bb28cc 5. /build/src/Interpreters/ProcessList.cpp:559: DB::QueryStatus::checkTimeLimit() @ 0x0000000014a4c2df 6. /build/src/Processors/Executors/PipelineExecutor.cpp:206: DB::PipelineExecutor::finalizeExecution() @ 0x00000000169b13ba 7. /build/src/Processors/Executors/PipelineExecutor.cpp:153: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x00000000169b0584 8. /build/src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:se190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169bfeab 9. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc3d92 10. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fcca080 11. ? @ 0x00007fbc6213eac3 12. ? @ 0x00007fbc621d0850 2025.07.28 11:58:00.424141 [ 17557 ] {} TCPHandler: Code: 159. DB::Exception: Timeout exceeded: elapsed 60018.922254 ms, maximum: 60000 ms. (TIMEOUT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, double&&, long&&) @ 0x0000000013bb358b 4. /build/src/QueryPipeline/ExecutionSpeedLimits.cpp:113: DB::ExecutionSpeedLimits::checkTimeLimit(unsigned long const&, DB::OverflowMode) const @ 0x0000000013bb28cc 5. /build/src/Interpreters/ProcessList.cpp:559: DB::QueryStatus::checkTimeLimit() @ 0x0000000014a4c2df 6. /build/src/Processors/Executors/PipelineExecutor.cpp:206: DB::PipelineExecutor::finalizeExecution() @ 0x00000000169b13ba 7. /build/src/Processors/Executors/PipelineExecutor.cpp:153: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x00000000169b0584 8. /build/src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:se190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169bfeab 9. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc3d92 10. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fcca080 11. ? @ 0x00007fbc6213eac3 12. ? @ 0x00007fbc621d0850 Job's origin stack trace: 0. /build/src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000000fc33b84 1. /build/src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000000fcc2ea7 2. /build/src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fcc535c 3. /build/src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000000fcc584d 4. /build/src/Common/ThreadPool.h:279: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x00000000169bf193 5. /build/src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x00000000169bf518 6. /build/src/Server/TCPHandler.cpp:1237: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x00000000168f1525 7. /build/src/Server/TCPHandler.cpp:678: DB::TCPHandler::runImpl() @ 0x00000000168e68e5 8. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 9. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 10. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 11. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 12. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 13. ? @ 0x00007fbc6213eac3 14. ? @ 0x00007fbc621d0850 2025.07.28 11:58:00.752317 [ 3287 ] {a53d6848-3dd0-4c91-84cd-50ef4c72fc2d} 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.6.10636.altinitytest (altinity build)) (from [::ffff:127.0.0.1]:42662) (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. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, char const*&, String&&, String&&) @ 0x0000000013bd4e0b 4. /build/src/QueryPipeline/SizeLimits.cpp:32: DB::SizeLimits::check(unsigned long, unsigned long, char const*, int, int) const @ 0x0000000013bd47b2 5. /build/src/Processors/QueryPlan/ReadFromSystemNumbersStep.cpp:627: DB::ReadFromSystemNumbersStep::checkLimits(unsigned long) @ 0x0000000016e914bc 6. /build/src/Processors/QueryPlan/ReadFromSystemNumbersStep.cpp:553: DB::ReadFromSystemNumbersStep::makePipe() @ 0x0000000016e90442 7. /build/src/Processors/QueryPlan/ReadFromSystemNumbersStep.cpp:431: DB::ReadFromSystemNumbersStep::initializePipeline(DB::QueryPipelineBuilder&, DB::BuildQueryPipelineSettings const&) @ 0x0000000016e8f064 8. /build/src/Processors/QueryPlan/ISourceStep.cpp:20: DB::ISourceStep::updatePipeline(std::vector>, std::allocator>>>, DB::BuildQueryPipelineSettings const&) @ 0x0000000016dd18d0 9. /build/src/Processors/QueryPlan/QueryPlan.cpp:201: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x0000000016e0076f 10. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:275: DB::InterpreterSelectQueryAnalyzer::buildQueryPipeline() @ 0x0000000014974614 11. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:242: DB::InterpreterSelectQueryAnalyzer::execute() @ 0x000000001497439e 12. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88dc9 13. /build/src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x0000000014c8ca7b 14. /build/src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000001686da12 15. /build/src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x0000000016870807 16. /build/src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x0000000016907e99 17. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 18. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 19. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 20. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 21. ? @ 0x00007fbc6213eac3 22. ? @ 0x00007fbc621d0850 2025.07.28 11:58:00.756300 [ 3287 ] {a53d6848-3dd0-4c91-84cd-50ef4c72fc2d} 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. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, char const*&, String&&, String&&) @ 0x0000000013bd4e0b 4. /build/src/QueryPipeline/SizeLimits.cpp:32: DB::SizeLimits::check(unsigned long, unsigned long, char const*, int, int) const @ 0x0000000013bd47b2 5. /build/src/Processors/QueryPlan/ReadFromSystemNumbersStep.cpp:627: DB::ReadFromSystemNumbersStep::checkLimits(unsigned long) @ 0x0000000016e914bc 6. /build/src/Processors/QueryPlan/ReadFromSystemNumbersStep.cpp:553: DB::ReadFromSystemNumbersStep::makePipe() @ 0x0000000016e90442 7. /build/src/Processors/QueryPlan/ReadFromSystemNumbersStep.cpp:431: DB::ReadFromSystemNumbersStep::initializePipeline(DB::QueryPipelineBuilder&, DB::BuildQueryPipelineSettings const&) @ 0x0000000016e8f064 8. /build/src/Processors/QueryPlan/ISourceStep.cpp:20: DB::ISourceStep::updatePipeline(std::vector>, std::allocator>>>, DB::BuildQueryPipelineSettings const&) @ 0x0000000016dd18d0 9. /build/src/Processors/QueryPlan/QueryPlan.cpp:201: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x0000000016e0076f 10. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:275: DB::InterpreterSelectQueryAnalyzer::buildQueryPipeline() @ 0x0000000014974614 11. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:242: DB::InterpreterSelectQueryAnalyzer::execute() @ 0x000000001497439e 12. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88dc9 13. /build/src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x0000000014c8ca7b 14. /build/src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000001686da12 15. /build/src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x0000000016870807 16. /build/src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x0000000016907e99 17. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 18. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 19. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 20. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 21. ? @ 0x00007fbc6213eac3 22. ? @ 0x00007fbc621d0850 (version 25.3.6.10636.altinitytest (altinity build)) 2025.07.28 11:58:00.841449 [ 3962 ] {} test_13.rmt2 (7f9b740d-015c-470e-8cc6-8ba33be0dc63): auto DB::StorageReplicatedMergeTree::processQueueEntry(ReplicatedMergeTreeQueue::SelectedEntryPtr)::(anonymous class)::operator()(LogEntryPtr &) const: Code: 86. DB::HTTPException: Received error from remote server http://146b4357c08d:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Ftest%2F01165%2Ftest_13%2Frmt%2Freplicas%2F1&part=20250728_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.6.10636.altinitytest (altinity build)) '. (RECEIVED_ERROR_FROM_REMOTE_IO_SERVER), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.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 const&, int&&, String const&, unsigned long&&, String const&) @ 0x000000000feda8d9 4. /build/src/IO/HTTPCommon.cpp:104: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x000000000feda6e2 5. /build/src/IO/HTTPCommon.cpp:93: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x000000000feda537 6. /build/src/IO/ReadWriteBufferFromHTTP.cpp:277: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x000000001184a4c4 7. /build/src/IO/ReadWriteBufferFromHTTP.cpp:285: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x000000001184a615 8. /build/src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x000000001184ae59 9. /build/src/IO/ReadWriteBufferFromHTTP.cpp:472: void std::__function::__policy_invoker::__call_impl[abi:se190107]>(std::__function::__policy_storage const*) @ 0x000000001184cedd 10. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001184858b 11. /build/src/IO/ReadWriteBufferFromHTTP.cpp:465: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x000000001184bf0b 12. /build/src/IO/ReadBuffer.h:60: DB::ReadBuffer::next() @ 0x000000000a148c7b 13. /build/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) @ 0x0000000011849fb2 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]>&)>&, 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&) @ 0x0000000011841980 15. /build/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) @ 0x000000001621208e 16. /build/src/Storages/StorageReplicatedMergeTree.cpp:5228: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl[abi:se190107] const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000015f9a5fe 17. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000015ed8bfd 18. /build/src/Storages/StorageReplicatedMergeTree.cpp:2514: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x0000000015ec9aab 19. /build/src/Storages/StorageReplicatedMergeTree.cpp:2349: DB::StorageReplicatedMergeTree::executeLogEntry(DB::ReplicatedMergeTreeLogEntry&) @ 0x0000000015eba91b 20. /build/src/Storages/StorageReplicatedMergeTree.cpp:3876: bool std::__function::__policy_invoker&)>::__call_impl[abi:se190107])::$_1, bool (std::shared_ptr&)>>(std::__function::__policy_storage const*, std::shared_ptr&) @ 0x0000000015f9837e 21. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000165d6fc3 22. /build/src/Storages/StorageReplicatedMergeTree.cpp:3872: DB::StorageReplicatedMergeTree::processQueueEntry(std::shared_ptr) @ 0x0000000015efc18a 23. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001624c1b2 24. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000162f9c70 25. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x00000000162fa55a 26. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc6653 27. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000000fccc4c3 28. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc3d92 29. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fcca080 30. ? @ 0x00007fbc6213eac3 31. ? @ 0x00007fbc621d0850 (version 25.3.6.10636.altinitytest (altinity build)) 2025.07.28 11:58:00.895122 [ 17207 ] {616b994a-ec80-4190-bc64-171ab9be716f} 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.6.10636.altinitytest (altinity build)) (from [::ffff:127.0.0.1]:42672) (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. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, char const*&, ReadableSize&&, ReadableSize&&) @ 0x0000000013bd4eeb 4. /build/src/QueryPipeline/SizeLimits.cpp:43: DB::SizeLimits::check(unsigned long, unsigned long, char const*, int, int) const @ 0x0000000013bd48a1 5. /build/src/Processors/Transforms/LimitsCheckingTransform.cpp:45: DB::LimitsCheckingTransform::transform(DB::Chunk&) @ 0x0000000016c1d2fb 6. /build/src/Processors/ISimpleTransform.h:33: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000011a9a453 7. /build/src/Processors/ISimpleTransform.cpp:89: DB::ISimpleTransform::work() @ 0x000000001699fca0 8. /build/src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x00000000169bd00f 9. /build/src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x00000000169b2105 10. /build/src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeSingleThread(unsigned long) @ 0x00000000169b23be 11. /build/src/Processors/Executors/PipelineExecutor.cpp:454: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x00000000169b0be7 12. /build/src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x00000000169b03f4 13. /build/src/Processors/Executors/CompletedPipelineExecutor.cpp:105: DB::CompletedPipelineExecutor::execute() @ 0x00000000169af3c4 14. /build/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&)>) @ 0x0000000014c8d123 15. /build/src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000001686da12 16. /build/src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x0000000016870807 17. /build/src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x0000000016907e99 18. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 19. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 20. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 21. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 22. ? @ 0x00007fbc6213eac3 23. ? @ 0x00007fbc621d0850 2025.07.28 11:58:00.897305 [ 17207 ] {616b994a-ec80-4190-bc64-171ab9be716f} 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. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, char const*&, ReadableSize&&, ReadableSize&&) @ 0x0000000013bd4eeb 4. /build/src/QueryPipeline/SizeLimits.cpp:43: DB::SizeLimits::check(unsigned long, unsigned long, char const*, int, int) const @ 0x0000000013bd48a1 5. /build/src/Processors/Transforms/LimitsCheckingTransform.cpp:45: DB::LimitsCheckingTransform::transform(DB::Chunk&) @ 0x0000000016c1d2fb 6. /build/src/Processors/ISimpleTransform.h:33: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000011a9a453 7. /build/src/Processors/ISimpleTransform.cpp:89: DB::ISimpleTransform::work() @ 0x000000001699fca0 8. /build/src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x00000000169bd00f 9. /build/src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x00000000169b2105 10. /build/src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeSingleThread(unsigned long) @ 0x00000000169b23be 11. /build/src/Processors/Executors/PipelineExecutor.cpp:454: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x00000000169b0be7 12. /build/src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x00000000169b03f4 13. /build/src/Processors/Executors/CompletedPipelineExecutor.cpp:105: DB::CompletedPipelineExecutor::execute() @ 0x00000000169af3c4 14. /build/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&)>) @ 0x0000000014c8d123 15. /build/src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000001686da12 16. /build/src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x0000000016870807 17. /build/src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x0000000016907e99 18. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 19. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 20. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 21. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 22. ? @ 0x00007fbc6213eac3 23. ? @ 0x00007fbc621d0850 (version 25.3.6.10636.altinitytest (altinity build)) 2025.07.28 11:58:01.055154 [ 17207 ] {dc82da72-b0cd-4aee-9a50-3b088db1d8d7} 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.6.10636.altinitytest (altinity build)) (from [::ffff:127.0.0.1]:42674) (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. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, char const*&, ReadableSize&&, ReadableSize&&) @ 0x0000000013bd4eeb 4. /build/src/QueryPipeline/SizeLimits.cpp:43: DB::SizeLimits::check(unsigned long, unsigned long, char const*, int, int) const @ 0x0000000013bd48a1 5. /build/src/Processors/Transforms/LimitsCheckingTransform.cpp:45: DB::LimitsCheckingTransform::transform(DB::Chunk&) @ 0x0000000016c1d2fb 6. /build/src/Processors/ISimpleTransform.h:33: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000011a9a453 7. /build/src/Processors/ISimpleTransform.cpp:89: DB::ISimpleTransform::work() @ 0x000000001699fca0 8. /build/src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x00000000169bd00f 9. /build/src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x00000000169b2105 10. /build/src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeSingleThread(unsigned long) @ 0x00000000169b23be 11. /build/src/Processors/Executors/PipelineExecutor.cpp:454: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x00000000169b0be7 12. /build/src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x00000000169b03f4 13. /build/src/Processors/Executors/CompletedPipelineExecutor.cpp:105: DB::CompletedPipelineExecutor::execute() @ 0x00000000169af3c4 14. /build/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&)>) @ 0x0000000014c8d123 15. /build/src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000001686da12 16. /build/src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x0000000016870807 17. /build/src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x0000000016907e99 18. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 19. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 20. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 21. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 22. ? @ 0x00007fbc6213eac3 23. ? @ 0x00007fbc621d0850 2025.07.28 11:58:01.065724 [ 17207 ] {dc82da72-b0cd-4aee-9a50-3b088db1d8d7} 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. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, char const*&, ReadableSize&&, ReadableSize&&) @ 0x0000000013bd4eeb 4. /build/src/QueryPipeline/SizeLimits.cpp:43: DB::SizeLimits::check(unsigned long, unsigned long, char const*, int, int) const @ 0x0000000013bd48a1 5. /build/src/Processors/Transforms/LimitsCheckingTransform.cpp:45: DB::LimitsCheckingTransform::transform(DB::Chunk&) @ 0x0000000016c1d2fb 6. /build/src/Processors/ISimpleTransform.h:33: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000011a9a453 7. /build/src/Processors/ISimpleTransform.cpp:89: DB::ISimpleTransform::work() @ 0x000000001699fca0 8. /build/src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x00000000169bd00f 9. /build/src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x00000000169b2105 10. /build/src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeSingleThread(unsigned long) @ 0x00000000169b23be 11. /build/src/Processors/Executors/PipelineExecutor.cpp:454: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x00000000169b0be7 12. /build/src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x00000000169b03f4 13. /build/src/Processors/Executors/CompletedPipelineExecutor.cpp:105: DB::CompletedPipelineExecutor::execute() @ 0x00000000169af3c4 14. /build/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&)>) @ 0x0000000014c8d123 15. /build/src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000001686da12 16. /build/src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x0000000016870807 17. /build/src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x0000000016907e99 18. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 19. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 20. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 21. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 22. ? @ 0x00007fbc6213eac3 23. ? @ 0x00007fbc621d0850 (version 25.3.6.10636.altinitytest (altinity build)) 2025.07.28 11:58:01.083385 [ 3969 ] {} test_13.rmt2 (7f9b740d-015c-470e-8cc6-8ba33be0dc63): auto DB::StorageReplicatedMergeTree::processQueueEntry(ReplicatedMergeTreeQueue::SelectedEntryPtr)::(anonymous class)::operator()(LogEntryPtr &) const: Code: 86. DB::HTTPException: Received error from remote server http://146b4357c08d:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Ftest%2F01165%2Ftest_13%2Frmt%2Freplicas%2F1&part=20250728_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.6.10636.altinitytest (altinity build)) '. (RECEIVED_ERROR_FROM_REMOTE_IO_SERVER), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.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 const&, int&&, String const&, unsigned long&&, String const&) @ 0x000000000feda8d9 4. /build/src/IO/HTTPCommon.cpp:104: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x000000000feda6e2 5. /build/src/IO/HTTPCommon.cpp:93: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x000000000feda537 6. /build/src/IO/ReadWriteBufferFromHTTP.cpp:277: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x000000001184a4c4 7. /build/src/IO/ReadWriteBufferFromHTTP.cpp:285: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x000000001184a615 8. /build/src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x000000001184ae59 9. /build/src/IO/ReadWriteBufferFromHTTP.cpp:472: void std::__function::__policy_invoker::__call_impl[abi:se190107]>(std::__function::__policy_storage const*) @ 0x000000001184cedd 10. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001184858b 11. /build/src/IO/ReadWriteBufferFromHTTP.cpp:465: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x000000001184bf0b 12. /build/src/IO/ReadBuffer.h:60: DB::ReadBuffer::next() @ 0x000000000a148c7b 13. /build/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) @ 0x0000000011849fb2 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]>&)>&, 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&) @ 0x0000000011841980 15. /build/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) @ 0x000000001621208e 16. /build/src/Storages/StorageReplicatedMergeTree.cpp:5228: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl[abi:se190107] const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000015f9a5fe 17. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000015ed8bfd 18. /build/src/Storages/StorageReplicatedMergeTree.cpp:2514: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x0000000015ec9aab 19. /build/src/Storages/StorageReplicatedMergeTree.cpp:2349: DB::StorageReplicatedMergeTree::executeLogEntry(DB::ReplicatedMergeTreeLogEntry&) @ 0x0000000015eba91b 20. /build/src/Storages/StorageReplicatedMergeTree.cpp:3876: bool std::__function::__policy_invoker&)>::__call_impl[abi:se190107])::$_1, bool (std::shared_ptr&)>>(std::__function::__policy_storage const*, std::shared_ptr&) @ 0x0000000015f9837e 21. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000165d6fc3 22. /build/src/Storages/StorageReplicatedMergeTree.cpp:3872: DB::StorageReplicatedMergeTree::processQueueEntry(std::shared_ptr) @ 0x0000000015efc18a 23. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001624c1b2 24. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000162f9c70 25. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x00000000162fa55a 26. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc6653 27. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000000fccc4c3 28. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc3d92 29. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fcca080 30. ? @ 0x00007fbc6213eac3 31. ? @ 0x00007fbc621d0850 (version 25.3.6.10636.altinitytest (altinity build)) 2025.07.28 11:58:01.512253 [ 3971 ] {} test_13.rmt2 (7f9b740d-015c-470e-8cc6-8ba33be0dc63): auto DB::StorageReplicatedMergeTree::processQueueEntry(ReplicatedMergeTreeQueue::SelectedEntryPtr)::(anonymous class)::operator()(LogEntryPtr &) const: Code: 86. DB::HTTPException: Received error from remote server http://146b4357c08d:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Ftest%2F01165%2Ftest_13%2Frmt%2Freplicas%2F1&part=20250728_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.6.10636.altinitytest (altinity build)) '. (RECEIVED_ERROR_FROM_REMOTE_IO_SERVER), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.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 const&, int&&, String const&, unsigned long&&, String const&) @ 0x000000000feda8d9 4. /build/src/IO/HTTPCommon.cpp:104: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x000000000feda6e2 5. /build/src/IO/HTTPCommon.cpp:93: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x000000000feda537 6. /build/src/IO/ReadWriteBufferFromHTTP.cpp:277: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x000000001184a4c4 7. /build/src/IO/ReadWriteBufferFromHTTP.cpp:285: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x000000001184a615 8. /build/src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x000000001184ae59 9. /build/src/IO/ReadWriteBufferFromHTTP.cpp:472: void std::__function::__policy_invoker::__call_impl[abi:se190107]>(std::__function::__policy_storage const*) @ 0x000000001184cedd 10. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001184858b 11. /build/src/IO/ReadWriteBufferFromHTTP.cpp:465: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x000000001184bf0b 12. /build/src/IO/ReadBuffer.h:60: DB::ReadBuffer::next() @ 0x000000000a148c7b 13. /build/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) @ 0x0000000011849fb2 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]>&)>&, 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&) @ 0x0000000011841980 15. /build/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) @ 0x000000001621208e 16. /build/src/Storages/StorageReplicatedMergeTree.cpp:5228: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl[abi:se190107] const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000015f9a5fe 17. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000015ed8bfd 18. /build/src/Storages/StorageReplicatedMergeTree.cpp:2514: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x0000000015ec9aab 19. /build/src/Storages/StorageReplicatedMergeTree.cpp:2349: DB::StorageReplicatedMergeTree::executeLogEntry(DB::ReplicatedMergeTreeLogEntry&) @ 0x0000000015eba91b 20. /build/src/Storages/StorageReplicatedMergeTree.cpp:3876: bool std::__function::__policy_invoker&)>::__call_impl[abi:se190107])::$_1, bool (std::shared_ptr&)>>(std::__function::__policy_storage const*, std::shared_ptr&) @ 0x0000000015f9837e 21. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000165d6fc3 22. /build/src/Storages/StorageReplicatedMergeTree.cpp:3872: DB::StorageReplicatedMergeTree::processQueueEntry(std::shared_ptr) @ 0x0000000015efc18a 23. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001624c1b2 24. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000162f9c70 25. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x00000000162fa55a 26. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc6653 27. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000000fccc4c3 28. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc3d92 29. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fcca080 30. ? @ 0x00007fbc6213eac3 31. ? @ 0x00007fbc621d0850 (version 25.3.6.10636.altinitytest (altinity build)) 2025.07.28 11:58:01.767560 [ 7630 ] {ced43935-b30a-4cc3-9c19-60e15ac8318e} executeQuery: Code: 62. DB::Exception: Cannot TRUNCATE dictionary. (SYNTAX_ERROR) (version 25.3.6.10636.altinitytest (altinity build)) (from [::1]:55144) (comment: 02294_dictionaries_hierarchical_index.sql) (query 15, line 50) (in query: DROP DICTIONARY hierarchy_hashed_dictionary_index;), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000000a074fcb 4. /build/src/Interpreters/InterpreterDropQuery.cpp:266: DB::InterpreterDropQuery::executeToTableImpl(std::shared_ptr const&, DB::ASTDropQuery&, std::shared_ptr&, StrongTypedef, DB::UUIDTag>&) @ 0x0000000014915b7b 5. /build/src/Interpreters/InterpreterDropQuery.cpp:118: DB::InterpreterDropQuery::executeToTable(DB::ASTDropQuery&) @ 0x00000000149137b4 6. /build/src/Interpreters/InterpreterDropQuery.cpp:91: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000014912f07 7. /build/src/Interpreters/InterpreterDropQuery.cpp:72: DB::InterpreterDropQuery::execute() @ 0x0000000014912b65 8. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88dc9 9. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 10. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 11. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 12. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 13. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 14. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 15. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 16. ? @ 0x00007fbc6213eac3 17. ? @ 0x00007fbc621d0850 2025.07.28 11:58:01.778103 [ 7630 ] {} TCPHandler: Code: 62. DB::Exception: Cannot TRUNCATE dictionary. (SYNTAX_ERROR), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000000a074fcb 4. /build/src/Interpreters/InterpreterDropQuery.cpp:266: DB::InterpreterDropQuery::executeToTableImpl(std::shared_ptr const&, DB::ASTDropQuery&, std::shared_ptr&, StrongTypedef, DB::UUIDTag>&) @ 0x0000000014915b7b 5. /build/src/Interpreters/InterpreterDropQuery.cpp:118: DB::InterpreterDropQuery::executeToTable(DB::ASTDropQuery&) @ 0x00000000149137b4 6. /build/src/Interpreters/InterpreterDropQuery.cpp:91: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000014912f07 7. /build/src/Interpreters/InterpreterDropQuery.cpp:72: DB::InterpreterDropQuery::execute() @ 0x0000000014912b65 8. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88dc9 9. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 10. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 11. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 12. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 13. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 14. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 15. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 16. ? @ 0x00007fbc6213eac3 17. ? @ 0x00007fbc621d0850 2025.07.28 11:58:01.857763 [ 17207 ] {48c28c9c-0370-4744-9f71-ca137ec5f086} 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.6.10636.altinitytest (altinity build)) (from [::ffff:127.0.0.1]:44022) (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. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, char const*&, ReadableSize&&, ReadableSize&&) @ 0x0000000013bd4eeb 4. /build/src/QueryPipeline/SizeLimits.cpp:43: DB::SizeLimits::check(unsigned long, unsigned long, char const*, int, int) const @ 0x0000000013bd48a1 5. /build/src/Processors/Transforms/LimitsCheckingTransform.cpp:45: DB::LimitsCheckingTransform::transform(DB::Chunk&) @ 0x0000000016c1d2fb 6. /build/src/Processors/ISimpleTransform.h:33: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000011a9a453 7. /build/src/Processors/ISimpleTransform.cpp:89: DB::ISimpleTransform::work() @ 0x000000001699fca0 8. /build/src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x00000000169bd00f 9. /build/src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x00000000169b2105 10. /build/src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeSingleThread(unsigned long) @ 0x00000000169b23be 11. /build/src/Processors/Executors/PipelineExecutor.cpp:454: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x00000000169b0be7 12. /build/src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x00000000169b03f4 13. /build/src/Processors/Executors/CompletedPipelineExecutor.cpp:105: DB::CompletedPipelineExecutor::execute() @ 0x00000000169af3c4 14. /build/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&)>) @ 0x0000000014c8d123 15. /build/src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000001686da12 16. /build/src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x0000000016870807 17. /build/src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x0000000016907e99 18. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 19. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 20. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 21. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 22. ? @ 0x00007fbc6213eac3 23. ? @ 0x00007fbc621d0850 2025.07.28 11:58:01.860060 [ 17207 ] {48c28c9c-0370-4744-9f71-ca137ec5f086} 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. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, char const*&, ReadableSize&&, ReadableSize&&) @ 0x0000000013bd4eeb 4. /build/src/QueryPipeline/SizeLimits.cpp:43: DB::SizeLimits::check(unsigned long, unsigned long, char const*, int, int) const @ 0x0000000013bd48a1 5. /build/src/Processors/Transforms/LimitsCheckingTransform.cpp:45: DB::LimitsCheckingTransform::transform(DB::Chunk&) @ 0x0000000016c1d2fb 6. /build/src/Processors/ISimpleTransform.h:33: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000011a9a453 7. /build/src/Processors/ISimpleTransform.cpp:89: DB::ISimpleTransform::work() @ 0x000000001699fca0 8. /build/src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x00000000169bd00f 9. /build/src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x00000000169b2105 10. /build/src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeSingleThread(unsigned long) @ 0x00000000169b23be 11. /build/src/Processors/Executors/PipelineExecutor.cpp:454: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x00000000169b0be7 12. /build/src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x00000000169b03f4 13. /build/src/Processors/Executors/CompletedPipelineExecutor.cpp:105: DB::CompletedPipelineExecutor::execute() @ 0x00000000169af3c4 14. /build/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&)>) @ 0x0000000014c8d123 15. /build/src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000001686da12 16. /build/src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x0000000016870807 17. /build/src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x0000000016907e99 18. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 19. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 20. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 21. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 22. ? @ 0x00007fbc6213eac3 23. ? @ 0x00007fbc621d0850 (version 25.3.6.10636.altinitytest (altinity build)) 2025.07.28 11:58:02.512534 [ 4446 ] {8455b168-7968-40ff-8fa6-3d8ceded4123} 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.6.10636.altinitytest (altinity build)) (from [::1]:55256) (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. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&) @ 0x000000000a10182b 4. /build/src/Functions/FunctionBinaryArithmetic.h:1931: DB::FunctionBinaryArithmetic::getReturnTypeImplStatic(std::vector, std::allocator>> const&, std::shared_ptr) @ 0x000000000d491a62 5. /build/src/Functions/IFunction.h:369: DB::IFunctionOverloadResolver::getReturnTypeImpl(std::vector> const&) const @ 0x000000000a6646de 6. /build/src/Functions/IFunction.cpp:645: DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x0000000012d96b0c 7. /build/src/Functions/IFunction.cpp:577: DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x0000000012d9669c 8. /build/src/Functions/IFunction.cpp:606: DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x0000000012d96edc 9. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3544: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000014033cc9 10. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3838: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000014019a9e 11. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3980: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000014018e31 12. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:4304: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000014042fa7 13. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5605: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000014013749 14. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000140127f9 15. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000014011fce 16. /build/src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000001406ce8a 17. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000014973b42 18. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000001497268d 19. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000014974d24 20. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001492924b 21. /build/src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88641 22. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 23. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 24. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 25. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 26. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 27. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 28. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 29. ? @ 0x00007fbc6213eac3 30. ? @ 0x00007fbc621d0850 2025.07.28 11:58:02.543075 [ 4446 ] {} 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. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&) @ 0x000000000a10182b 4. /build/src/Functions/FunctionBinaryArithmetic.h:1931: DB::FunctionBinaryArithmetic::getReturnTypeImplStatic(std::vector, std::allocator>> const&, std::shared_ptr) @ 0x000000000d491a62 5. /build/src/Functions/IFunction.h:369: DB::IFunctionOverloadResolver::getReturnTypeImpl(std::vector> const&) const @ 0x000000000a6646de 6. /build/src/Functions/IFunction.cpp:645: DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x0000000012d96b0c 7. /build/src/Functions/IFunction.cpp:577: DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x0000000012d9669c 8. /build/src/Functions/IFunction.cpp:606: DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x0000000012d96edc 9. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3544: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000014033cc9 10. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3838: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000014019a9e 11. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3980: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000014018e31 12. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:4304: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000014042fa7 13. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5605: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000014013749 14. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000140127f9 15. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000014011fce 16. /build/src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000001406ce8a 17. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000014973b42 18. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000001497268d 19. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000014974d24 20. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001492924b 21. /build/src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88641 22. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 23. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 24. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 25. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 26. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 27. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 28. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 29. ? @ 0x00007fbc6213eac3 30. ? @ 0x00007fbc621d0850 2025.07.28 11:58:02.553191 [ 3976 ] {} test_13.rmt2 (7f9b740d-015c-470e-8cc6-8ba33be0dc63): auto DB::StorageReplicatedMergeTree::processQueueEntry(ReplicatedMergeTreeQueue::SelectedEntryPtr)::(anonymous class)::operator()(LogEntryPtr &) const: Code: 86. DB::HTTPException: Received error from remote server http://146b4357c08d:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Ftest%2F01165%2Ftest_13%2Frmt%2Freplicas%2F1&part=20250728_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.6.10636.altinitytest (altinity build)) '. (RECEIVED_ERROR_FROM_REMOTE_IO_SERVER), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.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 const&, int&&, String const&, unsigned long&&, String const&) @ 0x000000000feda8d9 4. /build/src/IO/HTTPCommon.cpp:104: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x000000000feda6e2 5. /build/src/IO/HTTPCommon.cpp:93: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x000000000feda537 6. /build/src/IO/ReadWriteBufferFromHTTP.cpp:277: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x000000001184a4c4 7. /build/src/IO/ReadWriteBufferFromHTTP.cpp:285: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x000000001184a615 8. /build/src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x000000001184ae59 9. /build/src/IO/ReadWriteBufferFromHTTP.cpp:472: void std::__function::__policy_invoker::__call_impl[abi:se190107]>(std::__function::__policy_storage const*) @ 0x000000001184cedd 10. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001184858b 11. /build/src/IO/ReadWriteBufferFromHTTP.cpp:465: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x000000001184bf0b 12. /build/src/IO/ReadBuffer.h:60: DB::ReadBuffer::next() @ 0x000000000a148c7b 13. /build/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) @ 0x0000000011849fb2 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]>&)>&, 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&) @ 0x0000000011841980 15. /build/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) @ 0x000000001621208e 16. /build/src/Storages/StorageReplicatedMergeTree.cpp:5228: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl[abi:se190107] const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000015f9a5fe 17. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000015ed8bfd 18. /build/src/Storages/StorageReplicatedMergeTree.cpp:2514: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x0000000015ec9aab 19. /build/src/Storages/StorageReplicatedMergeTree.cpp:2349: DB::StorageReplicatedMergeTree::executeLogEntry(DB::ReplicatedMergeTreeLogEntry&) @ 0x0000000015eba91b 20. /build/src/Storages/StorageReplicatedMergeTree.cpp:3876: bool std::__function::__policy_invoker&)>::__call_impl[abi:se190107])::$_1, bool (std::shared_ptr&)>>(std::__function::__policy_storage const*, std::shared_ptr&) @ 0x0000000015f9837e 21. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000165d6fc3 22. /build/src/Storages/StorageReplicatedMergeTree.cpp:3872: DB::StorageReplicatedMergeTree::processQueueEntry(std::shared_ptr) @ 0x0000000015efc18a 23. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001624c1b2 24. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000162f9c70 25. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x00000000162fa55a 26. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc6653 27. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000000fccc4c3 28. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc3d92 29. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fcca080 30. ? @ 0x00007fbc6213eac3 31. ? @ 0x00007fbc621d0850 (version 25.3.6.10636.altinitytest (altinity build)) 2025.07.28 11:58:02.800928 [ 4446 ] {2ca58a3e-60e3-427b-a916-396c1f7cfa6c} 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.6.10636.altinitytest (altinity build)) (from [::1]:55256) (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. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x000000000a06b56b 4. /build/src/Functions/FunctionBinaryArithmetic.h:1368: DB::FunctionBinaryArithmetic::executeArraysImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000d07c342 5. /build/src/Functions/FunctionBinaryArithmetic.h:2515: DB::FunctionBinaryArithmetic::executeImpl2(std::vector> const&, std::shared_ptr const&, unsigned long, DB::PODArray, 63ul, 64ul> const*) const @ 0x000000000d078787 6. /build/src/Functions/FunctionBinaryArithmetic.h:2410: DB::FunctionBinaryArithmetic::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000d0761ff 7. /build/src/Functions/FunctionBinaryArithmetic.h:2645: DB::FunctionBinaryArithmeticWithConstants::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000d074e14 8. /build/src/Functions/FunctionBinaryArithmetic.h:1353: DB::FunctionBinaryArithmetic::executeArraysImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000d07b87d 9. /build/src/Functions/FunctionBinaryArithmetic.h:2515: DB::FunctionBinaryArithmetic::executeImpl2(std::vector> const&, std::shared_ptr const&, unsigned long, DB::PODArray, 63ul, 64ul> const*) const @ 0x000000000d078787 10. /build/src/Functions/FunctionBinaryArithmetic.h:2410: DB::FunctionBinaryArithmetic::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000d0761ff 11. /build/src/Functions/FunctionBinaryArithmetic.h:2645: DB::FunctionBinaryArithmeticWithConstants::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000d074e14 12. /build/src/Functions/IFunction.h:437: DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000a069f2a 13. /build/src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000012d9965a 14. /build/src/Functions/IFunction.cpp:351: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d93b02 15. /build/src/Functions/IFunction.cpp:420: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d95059 16. /build/src/Functions/IFunction.cpp:498: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d95c72 17. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3567: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000014034494 18. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3838: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000014019a9e 19. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3980: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000014018e31 20. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:4304: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000014042fa7 21. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5605: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000014013749 22. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000140127f9 23. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000014011fce 24. /build/src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000001406ce8a 25. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000014973b42 26. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000001497268d 27. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000014974d24 28. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001492924b 29. /build/src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88641 30. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 31. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 2025.07.28 11:58:02.826523 [ 4446 ] {} 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. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x000000000a06b56b 4. /build/src/Functions/FunctionBinaryArithmetic.h:1368: DB::FunctionBinaryArithmetic::executeArraysImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000d07c342 5. /build/src/Functions/FunctionBinaryArithmetic.h:2515: DB::FunctionBinaryArithmetic::executeImpl2(std::vector> const&, std::shared_ptr const&, unsigned long, DB::PODArray, 63ul, 64ul> const*) const @ 0x000000000d078787 6. /build/src/Functions/FunctionBinaryArithmetic.h:2410: DB::FunctionBinaryArithmetic::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000d0761ff 7. /build/src/Functions/FunctionBinaryArithmetic.h:2645: DB::FunctionBinaryArithmeticWithConstants::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000d074e14 8. /build/src/Functions/FunctionBinaryArithmetic.h:1353: DB::FunctionBinaryArithmetic::executeArraysImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000d07b87d 9. /build/src/Functions/FunctionBinaryArithmetic.h:2515: DB::FunctionBinaryArithmetic::executeImpl2(std::vector> const&, std::shared_ptr const&, unsigned long, DB::PODArray, 63ul, 64ul> const*) const @ 0x000000000d078787 10. /build/src/Functions/FunctionBinaryArithmetic.h:2410: DB::FunctionBinaryArithmetic::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000d0761ff 11. /build/src/Functions/FunctionBinaryArithmetic.h:2645: DB::FunctionBinaryArithmeticWithConstants::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000d074e14 12. /build/src/Functions/IFunction.h:437: DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000a069f2a 13. /build/src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000012d9965a 14. /build/src/Functions/IFunction.cpp:351: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d93b02 15. /build/src/Functions/IFunction.cpp:420: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d95059 16. /build/src/Functions/IFunction.cpp:498: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d95c72 17. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3567: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000014034494 18. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3838: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000014019a9e 19. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3980: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000014018e31 20. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:4304: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000014042fa7 21. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5605: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000014013749 22. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000140127f9 23. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000014011fce 24. /build/src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000001406ce8a 25. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000014973b42 26. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000001497268d 27. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000014974d24 28. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001492924b 29. /build/src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88641 30. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 31. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 2025.07.28 11:58:03.084274 [ 4446 ] {a41883cd-91fc-4b91-8cbc-aae2f39864c6} 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.6.10636.altinitytest (altinity build)) (from [::1]:55256) (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. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x000000000a06b56b 4. /build/src/Functions/FunctionBinaryArithmetic.h:1368: DB::FunctionBinaryArithmetic::executeArraysImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000df742e2 5. /build/src/Functions/FunctionBinaryArithmetic.h:2515: DB::FunctionBinaryArithmetic::executeImpl2(std::vector> const&, std::shared_ptr const&, unsigned long, DB::PODArray, 63ul, 64ul> const*) const @ 0x000000000df70b67 6. /build/src/Functions/FunctionBinaryArithmetic.h:2410: DB::FunctionBinaryArithmetic::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000df6e798 7. /build/src/Functions/IFunctionAdaptors.cpp:10: DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000012d995fa 8. /build/src/Functions/IFunction.cpp:353: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d93b52 9. /build/src/Functions/IFunction.cpp:420: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d95059 10. /build/src/Functions/IFunction.cpp:498: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d95c72 11. /build/src/Interpreters/ExpressionActions.cpp:636: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x00000000145176f3 12. /build/src/Processors/Transforms/ExpressionTransform.cpp:25: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x0000000016c0b34c 13. /build/src/Processors/ISimpleTransform.h:33: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000011a9a453 14. /build/src/Processors/ISimpleTransform.cpp:89: DB::ISimpleTransform::work() @ 0x000000001699fca0 15. /build/src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x00000000169bd00f 16. /build/src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x00000000169b2105 17. /build/src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeSingleThread(unsigned long) @ 0x00000000169b23be 18. /build/src/Processors/Executors/PipelineExecutor.cpp:454: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x00000000169b0be7 19. /build/src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x00000000169b03f4 20. /build/src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:se190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169bfeab 21. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc3d92 22. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fcca080 23. ? @ 0x00007fbc6213eac3 24. ? @ 0x00007fbc621d0850 2025.07.28 11:58:03.088777 [ 4446 ] {} 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. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x000000000a06b56b 4. /build/src/Functions/FunctionBinaryArithmetic.h:1368: DB::FunctionBinaryArithmetic::executeArraysImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000df742e2 5. /build/src/Functions/FunctionBinaryArithmetic.h:2515: DB::FunctionBinaryArithmetic::executeImpl2(std::vector> const&, std::shared_ptr const&, unsigned long, DB::PODArray, 63ul, 64ul> const*) const @ 0x000000000df70b67 6. /build/src/Functions/FunctionBinaryArithmetic.h:2410: DB::FunctionBinaryArithmetic::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000df6e798 7. /build/src/Functions/IFunctionAdaptors.cpp:10: DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000012d995fa 8. /build/src/Functions/IFunction.cpp:353: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d93b52 9. /build/src/Functions/IFunction.cpp:420: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d95059 10. /build/src/Functions/IFunction.cpp:498: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d95c72 11. /build/src/Interpreters/ExpressionActions.cpp:636: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x00000000145176f3 12. /build/src/Processors/Transforms/ExpressionTransform.cpp:25: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x0000000016c0b34c 13. /build/src/Processors/ISimpleTransform.h:33: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000011a9a453 14. /build/src/Processors/ISimpleTransform.cpp:89: DB::ISimpleTransform::work() @ 0x000000001699fca0 15. /build/src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x00000000169bd00f 16. /build/src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x00000000169b2105 17. /build/src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeSingleThread(unsigned long) @ 0x00000000169b23be 18. /build/src/Processors/Executors/PipelineExecutor.cpp:454: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x00000000169b0be7 19. /build/src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x00000000169b03f4 20. /build/src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:se190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169bfeab 21. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc3d92 22. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fcca080 23. ? @ 0x00007fbc6213eac3 24. ? @ 0x00007fbc621d0850 Job's origin stack trace: 0. /build/src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000000fc33b84 1. /build/src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000000fcc2ea7 2. /build/src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fcc535c 3. /build/src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000000fcc584d 4. /build/src/Common/ThreadPool.h:279: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x00000000169bf193 5. /build/src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x00000000169bf518 6. /build/src/Server/TCPHandler.cpp:1237: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x00000000168f1525 7. /build/src/Server/TCPHandler.cpp:678: DB::TCPHandler::runImpl() @ 0x00000000168e68e5 8. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 9. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 10. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 11. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 12. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 13. ? @ 0x00007fbc6213eac3 14. ? @ 0x00007fbc621d0850 2025.07.28 11:58:03.531657 [ 17232 ] {d0a4aaec-42ce-48e5-bc36-6bc66f933bd0} 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.6.10636.altinitytest (altinity build)) (from [::ffff:127.0.0.1]:44026) (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. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, char const*&, ReadableSize&&, ReadableSize&&) @ 0x0000000013bd4eeb 4. /build/src/QueryPipeline/SizeLimits.cpp:43: DB::SizeLimits::check(unsigned long, unsigned long, char const*, int, int) const @ 0x0000000013bd48a1 5. /build/src/Processors/Transforms/LimitsCheckingTransform.cpp:45: DB::LimitsCheckingTransform::transform(DB::Chunk&) @ 0x0000000016c1d2fb 6. /build/src/Processors/ISimpleTransform.h:33: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000011a9a453 7. /build/src/Processors/ISimpleTransform.cpp:89: DB::ISimpleTransform::work() @ 0x000000001699fca0 8. /build/src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x00000000169bd00f 9. /build/src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x00000000169b2105 10. /build/src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeSingleThread(unsigned long) @ 0x00000000169b23be 11. /build/src/Processors/Executors/PipelineExecutor.cpp:454: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x00000000169b0be7 12. /build/src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x00000000169b03f4 13. /build/src/Processors/Executors/CompletedPipelineExecutor.cpp:105: DB::CompletedPipelineExecutor::execute() @ 0x00000000169af3c4 14. /build/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&)>) @ 0x0000000014c8d123 15. /build/src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000001686da12 16. /build/src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x0000000016870807 17. /build/src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x0000000016907e99 18. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 19. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 20. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 21. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 22. ? @ 0x00007fbc6213eac3 23. ? @ 0x00007fbc621d0850 2025.07.28 11:58:03.539843 [ 17232 ] {d0a4aaec-42ce-48e5-bc36-6bc66f933bd0} 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. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, char const*&, ReadableSize&&, ReadableSize&&) @ 0x0000000013bd4eeb 4. /build/src/QueryPipeline/SizeLimits.cpp:43: DB::SizeLimits::check(unsigned long, unsigned long, char const*, int, int) const @ 0x0000000013bd48a1 5. /build/src/Processors/Transforms/LimitsCheckingTransform.cpp:45: DB::LimitsCheckingTransform::transform(DB::Chunk&) @ 0x0000000016c1d2fb 6. /build/src/Processors/ISimpleTransform.h:33: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000011a9a453 7. /build/src/Processors/ISimpleTransform.cpp:89: DB::ISimpleTransform::work() @ 0x000000001699fca0 8. /build/src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x00000000169bd00f 9. /build/src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x00000000169b2105 10. /build/src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeSingleThread(unsigned long) @ 0x00000000169b23be 11. /build/src/Processors/Executors/PipelineExecutor.cpp:454: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x00000000169b0be7 12. /build/src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x00000000169b03f4 13. /build/src/Processors/Executors/CompletedPipelineExecutor.cpp:105: DB::CompletedPipelineExecutor::execute() @ 0x00000000169af3c4 14. /build/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&)>) @ 0x0000000014c8d123 15. /build/src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000001686da12 16. /build/src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x0000000016870807 17. /build/src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x0000000016907e99 18. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 19. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 20. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 21. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 22. ? @ 0x00007fbc6213eac3 23. ? @ 0x00007fbc621d0850 (version 25.3.6.10636.altinitytest (altinity build)) 2025.07.28 11:58:03.571672 [ 3971 ] {} test_13.rmt2 (7f9b740d-015c-470e-8cc6-8ba33be0dc63): auto DB::StorageReplicatedMergeTree::processQueueEntry(ReplicatedMergeTreeQueue::SelectedEntryPtr)::(anonymous class)::operator()(LogEntryPtr &) const: Code: 86. DB::HTTPException: Received error from remote server http://146b4357c08d:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Ftest%2F01165%2Ftest_13%2Frmt%2Freplicas%2F1&part=20250728_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.6.10636.altinitytest (altinity build)) '. (RECEIVED_ERROR_FROM_REMOTE_IO_SERVER), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.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 const&, int&&, String const&, unsigned long&&, String const&) @ 0x000000000feda8d9 4. /build/src/IO/HTTPCommon.cpp:104: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x000000000feda6e2 5. /build/src/IO/HTTPCommon.cpp:93: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x000000000feda537 6. /build/src/IO/ReadWriteBufferFromHTTP.cpp:277: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x000000001184a4c4 7. /build/src/IO/ReadWriteBufferFromHTTP.cpp:285: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x000000001184a615 8. /build/src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x000000001184ae59 9. /build/src/IO/ReadWriteBufferFromHTTP.cpp:472: void std::__function::__policy_invoker::__call_impl[abi:se190107]>(std::__function::__policy_storage const*) @ 0x000000001184cedd 10. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001184858b 11. /build/src/IO/ReadWriteBufferFromHTTP.cpp:465: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x000000001184bf0b 12. /build/src/IO/ReadBuffer.h:60: DB::ReadBuffer::next() @ 0x000000000a148c7b 13. /build/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) @ 0x0000000011849fb2 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]>&)>&, 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&) @ 0x0000000011841980 15. /build/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) @ 0x000000001621208e 16. /build/src/Storages/StorageReplicatedMergeTree.cpp:5228: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl[abi:se190107] const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000015f9a5fe 17. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000015ed8bfd 18. /build/src/Storages/StorageReplicatedMergeTree.cpp:2514: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x0000000015ec9aab 19. /build/src/Storages/StorageReplicatedMergeTree.cpp:2349: DB::StorageReplicatedMergeTree::executeLogEntry(DB::ReplicatedMergeTreeLogEntry&) @ 0x0000000015eba91b 20. /build/src/Storages/StorageReplicatedMergeTree.cpp:3876: bool std::__function::__policy_invoker&)>::__call_impl[abi:se190107])::$_1, bool (std::shared_ptr&)>>(std::__function::__policy_storage const*, std::shared_ptr&) @ 0x0000000015f9837e 21. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000165d6fc3 22. /build/src/Storages/StorageReplicatedMergeTree.cpp:3872: DB::StorageReplicatedMergeTree::processQueueEntry(std::shared_ptr) @ 0x0000000015efc18a 23. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001624c1b2 24. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000162f9c70 25. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x00000000162fa55a 26. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc6653 27. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000000fccc4c3 28. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc3d92 29. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fcca080 30. ? @ 0x00007fbc6213eac3 31. ? @ 0x00007fbc621d0850 (version 25.3.6.10636.altinitytest (altinity build)) 2025.07.28 11:58:04.538867 [ 7625 ] {d4cf5da9-030d-4e56-a0e7-4a04c0d072f2} 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.6.10636.altinitytest (altinity build)) (from [::ffff:127.0.0.1]:44030) (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. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, char const*&, ReadableSize&&, ReadableSize&&) @ 0x0000000013bd4eeb 4. /build/src/QueryPipeline/SizeLimits.cpp:43: DB::SizeLimits::check(unsigned long, unsigned long, char const*, int, int) const @ 0x0000000013bd48a1 5. /build/src/Processors/Transforms/LimitsCheckingTransform.cpp:45: DB::LimitsCheckingTransform::transform(DB::Chunk&) @ 0x0000000016c1d2fb 6. /build/src/Processors/ISimpleTransform.h:33: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000011a9a453 7. /build/src/Processors/ISimpleTransform.cpp:89: DB::ISimpleTransform::work() @ 0x000000001699fca0 8. /build/src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x00000000169bd00f 9. /build/src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x00000000169b2105 10. /build/src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeSingleThread(unsigned long) @ 0x00000000169b23be 11. /build/src/Processors/Executors/PipelineExecutor.cpp:454: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x00000000169b0be7 12. /build/src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x00000000169b03f4 13. /build/src/Processors/Executors/CompletedPipelineExecutor.cpp:105: DB::CompletedPipelineExecutor::execute() @ 0x00000000169af3c4 14. /build/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&)>) @ 0x0000000014c8d123 15. /build/src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000001686da12 16. /build/src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x0000000016870807 17. /build/src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x0000000016907e99 18. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 19. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 20. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 21. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 22. ? @ 0x00007fbc6213eac3 23. ? @ 0x00007fbc621d0850 2025.07.28 11:58:04.542150 [ 7625 ] {d4cf5da9-030d-4e56-a0e7-4a04c0d072f2} 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. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, char const*&, ReadableSize&&, ReadableSize&&) @ 0x0000000013bd4eeb 4. /build/src/QueryPipeline/SizeLimits.cpp:43: DB::SizeLimits::check(unsigned long, unsigned long, char const*, int, int) const @ 0x0000000013bd48a1 5. /build/src/Processors/Transforms/LimitsCheckingTransform.cpp:45: DB::LimitsCheckingTransform::transform(DB::Chunk&) @ 0x0000000016c1d2fb 6. /build/src/Processors/ISimpleTransform.h:33: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000011a9a453 7. /build/src/Processors/ISimpleTransform.cpp:89: DB::ISimpleTransform::work() @ 0x000000001699fca0 8. /build/src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x00000000169bd00f 9. /build/src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x00000000169b2105 10. /build/src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeSingleThread(unsigned long) @ 0x00000000169b23be 11. /build/src/Processors/Executors/PipelineExecutor.cpp:454: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x00000000169b0be7 12. /build/src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x00000000169b03f4 13. /build/src/Processors/Executors/CompletedPipelineExecutor.cpp:105: DB::CompletedPipelineExecutor::execute() @ 0x00000000169af3c4 14. /build/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&)>) @ 0x0000000014c8d123 15. /build/src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000001686da12 16. /build/src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x0000000016870807 17. /build/src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x0000000016907e99 18. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 19. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 20. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 21. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 22. ? @ 0x00007fbc6213eac3 23. ? @ 0x00007fbc621d0850 (version 25.3.6.10636.altinitytest (altinity build)) 2025.07.28 11:58:04.661620 [ 3967 ] {} test_13.rmt2 (7f9b740d-015c-470e-8cc6-8ba33be0dc63): auto DB::StorageReplicatedMergeTree::processQueueEntry(ReplicatedMergeTreeQueue::SelectedEntryPtr)::(anonymous class)::operator()(LogEntryPtr &) const: Code: 86. DB::HTTPException: Received error from remote server http://146b4357c08d:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Ftest%2F01165%2Ftest_13%2Frmt%2Freplicas%2F1&part=20250728_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.6.10636.altinitytest (altinity build)) '. (RECEIVED_ERROR_FROM_REMOTE_IO_SERVER), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.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 const&, int&&, String const&, unsigned long&&, String const&) @ 0x000000000feda8d9 4. /build/src/IO/HTTPCommon.cpp:104: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x000000000feda6e2 5. /build/src/IO/HTTPCommon.cpp:93: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x000000000feda537 6. /build/src/IO/ReadWriteBufferFromHTTP.cpp:277: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x000000001184a4c4 7. /build/src/IO/ReadWriteBufferFromHTTP.cpp:285: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x000000001184a615 8. /build/src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x000000001184ae59 9. /build/src/IO/ReadWriteBufferFromHTTP.cpp:472: void std::__function::__policy_invoker::__call_impl[abi:se190107]>(std::__function::__policy_storage const*) @ 0x000000001184cedd 10. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001184858b 11. /build/src/IO/ReadWriteBufferFromHTTP.cpp:465: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x000000001184bf0b 12. /build/src/IO/ReadBuffer.h:60: DB::ReadBuffer::next() @ 0x000000000a148c7b 13. /build/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) @ 0x0000000011849fb2 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]>&)>&, 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&) @ 0x0000000011841980 15. /build/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) @ 0x000000001621208e 16. /build/src/Storages/StorageReplicatedMergeTree.cpp:5228: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl[abi:se190107] const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000015f9a5fe 17. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000015ed8bfd 18. /build/src/Storages/StorageReplicatedMergeTree.cpp:2514: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x0000000015ec9aab 19. /build/src/Storages/StorageReplicatedMergeTree.cpp:2349: DB::StorageReplicatedMergeTree::executeLogEntry(DB::ReplicatedMergeTreeLogEntry&) @ 0x0000000015eba91b 20. /build/src/Storages/StorageReplicatedMergeTree.cpp:3876: bool std::__function::__policy_invoker&)>::__call_impl[abi:se190107])::$_1, bool (std::shared_ptr&)>>(std::__function::__policy_storage const*, std::shared_ptr&) @ 0x0000000015f9837e 21. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000165d6fc3 22. /build/src/Storages/StorageReplicatedMergeTree.cpp:3872: DB::StorageReplicatedMergeTree::processQueueEntry(std::shared_ptr) @ 0x0000000015efc18a 23. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001624c1b2 24. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000162f9c70 25. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x00000000162fa55a 26. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc6653 27. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000000fccc4c3 28. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc3d92 29. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fcca080 30. ? @ 0x00007fbc6213eac3 31. ? @ 0x00007fbc621d0850 (version 25.3.6.10636.altinitytest (altinity build)) 2025.07.28 11:58:05.345823 [ 7625 ] {5866df1f-b3ce-4983-a258-e7ca160e2ad3} 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.6.10636.altinitytest (altinity build)) (from [::ffff:127.0.0.1]:44038) (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. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, char const*&, ReadableSize&&, ReadableSize&&) @ 0x0000000013bd4eeb 4. /build/src/QueryPipeline/SizeLimits.cpp:43: DB::SizeLimits::check(unsigned long, unsigned long, char const*, int, int) const @ 0x0000000013bd48a1 5. /build/src/Processors/Transforms/LimitsCheckingTransform.cpp:45: DB::LimitsCheckingTransform::transform(DB::Chunk&) @ 0x0000000016c1d2fb 6. /build/src/Processors/ISimpleTransform.h:33: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000011a9a453 7. /build/src/Processors/ISimpleTransform.cpp:89: DB::ISimpleTransform::work() @ 0x000000001699fca0 8. /build/src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x00000000169bd00f 9. /build/src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x00000000169b2105 10. /build/src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeSingleThread(unsigned long) @ 0x00000000169b23be 11. /build/src/Processors/Executors/PipelineExecutor.cpp:454: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x00000000169b0be7 12. /build/src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x00000000169b03f4 13. /build/src/Processors/Executors/CompletedPipelineExecutor.cpp:105: DB::CompletedPipelineExecutor::execute() @ 0x00000000169af3c4 14. /build/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&)>) @ 0x0000000014c8d123 15. /build/src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000001686da12 16. /build/src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x0000000016870807 17. /build/src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x0000000016907e99 18. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 19. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 20. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 21. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 22. ? @ 0x00007fbc6213eac3 23. ? @ 0x00007fbc621d0850 2025.07.28 11:58:05.348981 [ 7625 ] {5866df1f-b3ce-4983-a258-e7ca160e2ad3} 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. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, char const*&, ReadableSize&&, ReadableSize&&) @ 0x0000000013bd4eeb 4. /build/src/QueryPipeline/SizeLimits.cpp:43: DB::SizeLimits::check(unsigned long, unsigned long, char const*, int, int) const @ 0x0000000013bd48a1 5. /build/src/Processors/Transforms/LimitsCheckingTransform.cpp:45: DB::LimitsCheckingTransform::transform(DB::Chunk&) @ 0x0000000016c1d2fb 6. /build/src/Processors/ISimpleTransform.h:33: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000011a9a453 7. /build/src/Processors/ISimpleTransform.cpp:89: DB::ISimpleTransform::work() @ 0x000000001699fca0 8. /build/src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x00000000169bd00f 9. /build/src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x00000000169b2105 10. /build/src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeSingleThread(unsigned long) @ 0x00000000169b23be 11. /build/src/Processors/Executors/PipelineExecutor.cpp:454: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x00000000169b0be7 12. /build/src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x00000000169b03f4 13. /build/src/Processors/Executors/CompletedPipelineExecutor.cpp:105: DB::CompletedPipelineExecutor::execute() @ 0x00000000169af3c4 14. /build/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&)>) @ 0x0000000014c8d123 15. /build/src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000001686da12 16. /build/src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x0000000016870807 17. /build/src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x0000000016907e99 18. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 19. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 20. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 21. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 22. ? @ 0x00007fbc6213eac3 23. ? @ 0x00007fbc621d0850 (version 25.3.6.10636.altinitytest (altinity build)) 2025.07.28 11:58:05.408394 [ 3972 ] {} test_13.rmt2 (7f9b740d-015c-470e-8cc6-8ba33be0dc63): auto DB::StorageReplicatedMergeTree::processQueueEntry(ReplicatedMergeTreeQueue::SelectedEntryPtr)::(anonymous class)::operator()(LogEntryPtr &) const: Code: 86. DB::HTTPException: Received error from remote server http://146b4357c08d:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Ftest%2F01165%2Ftest_13%2Frmt%2Freplicas%2F1&part=20250728_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.6.10636.altinitytest (altinity build)) '. (RECEIVED_ERROR_FROM_REMOTE_IO_SERVER), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.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 const&, int&&, String const&, unsigned long&&, String const&) @ 0x000000000feda8d9 4. /build/src/IO/HTTPCommon.cpp:104: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x000000000feda6e2 5. /build/src/IO/HTTPCommon.cpp:93: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x000000000feda537 6. /build/src/IO/ReadWriteBufferFromHTTP.cpp:277: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x000000001184a4c4 7. /build/src/IO/ReadWriteBufferFromHTTP.cpp:285: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x000000001184a615 8. /build/src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x000000001184ae59 9. /build/src/IO/ReadWriteBufferFromHTTP.cpp:472: void std::__function::__policy_invoker::__call_impl[abi:se190107]>(std::__function::__policy_storage const*) @ 0x000000001184cedd 10. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001184858b 11. /build/src/IO/ReadWriteBufferFromHTTP.cpp:465: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x000000001184bf0b 12. /build/src/IO/ReadBuffer.h:60: DB::ReadBuffer::next() @ 0x000000000a148c7b 13. /build/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) @ 0x0000000011849fb2 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]>&)>&, 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&) @ 0x0000000011841980 15. /build/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) @ 0x000000001621208e 16. /build/src/Storages/StorageReplicatedMergeTree.cpp:5228: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl[abi:se190107] const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000015f9a5fe 17. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000015ed8bfd 18. /build/src/Storages/StorageReplicatedMergeTree.cpp:2514: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x0000000015ec9aab 19. /build/src/Storages/StorageReplicatedMergeTree.cpp:2349: DB::StorageReplicatedMergeTree::executeLogEntry(DB::ReplicatedMergeTreeLogEntry&) @ 0x0000000015eba91b 20. /build/src/Storages/StorageReplicatedMergeTree.cpp:3876: bool std::__function::__policy_invoker&)>::__call_impl[abi:se190107])::$_1, bool (std::shared_ptr&)>>(std::__function::__policy_storage const*, std::shared_ptr&) @ 0x0000000015f9837e 21. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000165d6fc3 22. /build/src/Storages/StorageReplicatedMergeTree.cpp:3872: DB::StorageReplicatedMergeTree::processQueueEntry(std::shared_ptr) @ 0x0000000015efc18a 23. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001624c1b2 24. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000162f9c70 25. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x00000000162fa55a 26. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc6653 27. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000000fccc4c3 28. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc3d92 29. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fcca080 30. ? @ 0x00007fbc6213eac3 31. ? @ 0x00007fbc621d0850 (version 25.3.6.10636.altinitytest (altinity build)) 2025.07.28 11:58:05.567626 [ 5747 ] {42c62137-d93f-47f8-be47-8f4a93447454} executeQuery: Code: 47. DB::Exception: Qualified matcher statement1.* does not find table. In scope WITH statement1 AS (SELECT '' AS name FROM test_table), statement2 AS (SELECT '' AS name FROM test_table) SELECT statement1.*, statement2.*. (UNKNOWN_IDENTIFIER) (version 25.3.6.10636.altinitytest (altinity build)) (from [::1]:38242) (comment: 03356_analyzer_qualified_matcher_error.sql) (query 2, line 8) (in query: WITH statement1 AS ( SELECT '' AS name FROM test_table ), statement2 AS ( SELECT '' AS name FROM test_table ) SELECT statement1.*, statement2.*;), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000a06a8eb 4. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:1882: DB::QueryAnalyzer::resolveQualifiedMatcher(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000001402dd71 5. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:2204: DB::QueryAnalyzer::resolveMatcher(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000001403b351 6. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3801: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000014019d28 7. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3980: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000014018e31 8. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:4304: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000014042fa7 9. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5605: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000014013749 10. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000140127f9 11. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000014011fce 12. /build/src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000001406ce8a 13. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000014973b42 14. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000001497268d 15. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000014974d24 16. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001492924b 17. /build/src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88641 18. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 19. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 20. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 21. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 22. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 23. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 24. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 25. ? @ 0x00007fbc6213eac3 26. ? @ 0x00007fbc621d0850 2025.07.28 11:58:05.571295 [ 5747 ] {} TCPHandler: Code: 47. DB::Exception: Qualified matcher statement1.* does not find table. In scope WITH statement1 AS (SELECT '' AS name FROM test_table), statement2 AS (SELECT '' AS name FROM test_table) SELECT statement1.*, statement2.*. (UNKNOWN_IDENTIFIER), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000a06a8eb 4. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:1882: DB::QueryAnalyzer::resolveQualifiedMatcher(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000001402dd71 5. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:2204: DB::QueryAnalyzer::resolveMatcher(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000001403b351 6. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3801: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000014019d28 7. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3980: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000014018e31 8. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:4304: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000014042fa7 9. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5605: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000014013749 10. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000140127f9 11. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000014011fce 12. /build/src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000001406ce8a 13. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000014973b42 14. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000001497268d 15. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000014974d24 16. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001492924b 17. /build/src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88641 18. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 19. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 20. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 21. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 22. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 23. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 24. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 25. ? @ 0x00007fbc6213eac3 26. ? @ 0x00007fbc621d0850 2025.07.28 11:58:05.665794 [ 5747 ] {7069cdd1-3586-48ce-b1df-ebc7fadddc9b} executeQuery: Code: 47. DB::Exception: Qualified matcher t.* does not find table. In scope WITH t AS (SELECT sum(number) AS x FROM numbers(10)) SELECT t.*. (UNKNOWN_IDENTIFIER) (version 25.3.6.10636.altinitytest (altinity build)) (from [::1]:38242) (comment: 03356_analyzer_qualified_matcher_error.sql) (query 3, line 23) (in query: WITH t as (SELECT sum(number) as x FROM numbers(10)) SELECT t.*;), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000a06a8eb 4. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:1882: DB::QueryAnalyzer::resolveQualifiedMatcher(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000001402dd71 5. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:2204: DB::QueryAnalyzer::resolveMatcher(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000001403b351 6. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3801: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000014019d28 7. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3980: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000014018e31 8. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:4304: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000014042fa7 9. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5605: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000014013749 10. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000140127f9 11. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000014011fce 12. /build/src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000001406ce8a 13. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000014973b42 14. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000001497268d 15. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000014974d24 16. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001492924b 17. /build/src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88641 18. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 19. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 20. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 21. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 22. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 23. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 24. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 25. ? @ 0x00007fbc6213eac3 26. ? @ 0x00007fbc621d0850 2025.07.28 11:58:05.668519 [ 5747 ] {} TCPHandler: Code: 47. DB::Exception: Qualified matcher t.* does not find table. In scope WITH t AS (SELECT sum(number) AS x FROM numbers(10)) SELECT t.*. (UNKNOWN_IDENTIFIER), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000a06a8eb 4. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:1882: DB::QueryAnalyzer::resolveQualifiedMatcher(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000001402dd71 5. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:2204: DB::QueryAnalyzer::resolveMatcher(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000001403b351 6. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3801: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000014019d28 7. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3980: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000014018e31 8. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:4304: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000014042fa7 9. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5605: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000014013749 10. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000140127f9 11. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000014011fce 12. /build/src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000001406ce8a 13. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000014973b42 14. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000001497268d 15. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000014974d24 16. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001492924b 17. /build/src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88641 18. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 19. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 20. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 21. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 22. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 23. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 24. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 25. ? @ 0x00007fbc6213eac3 26. ? @ 0x00007fbc621d0850 2025.07.28 11:58:05.691951 [ 5747 ] {7564ceb7-1ba6-412a-8d91-0adb23c3c1f1} executeQuery: Code: 47. DB::Exception: Qualified matcher a.* does not find table. In scope WITH a AS (SELECT 1) SELECT a.* FROM (SELECT 1 FROM a). (UNKNOWN_IDENTIFIER) (version 25.3.6.10636.altinitytest (altinity build)) (from [::1]:38242) (comment: 03356_analyzer_qualified_matcher_error.sql) (query 4, line 27) (in query: WITH a AS (SELECT 1) SELECT a.* FROM (SELECT 1 FROM a);), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000a06a8eb 4. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:1882: DB::QueryAnalyzer::resolveQualifiedMatcher(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000001402dd71 5. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:2204: DB::QueryAnalyzer::resolveMatcher(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000001403b351 6. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3801: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000014019d28 7. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3980: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000014018e31 8. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:4304: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000014042fa7 9. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5605: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000014013749 10. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000140127f9 11. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000014011fce 12. /build/src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000001406ce8a 13. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000014973b42 14. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000001497268d 15. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000014974d24 16. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001492924b 17. /build/src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88641 18. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 19. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 20. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 21. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 22. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 23. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 24. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 25. ? @ 0x00007fbc6213eac3 26. ? @ 0x00007fbc621d0850 2025.07.28 11:58:05.695767 [ 5747 ] {} TCPHandler: Code: 47. DB::Exception: Qualified matcher a.* does not find table. In scope WITH a AS (SELECT 1) SELECT a.* FROM (SELECT 1 FROM a). (UNKNOWN_IDENTIFIER), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000a06a8eb 4. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:1882: DB::QueryAnalyzer::resolveQualifiedMatcher(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000001402dd71 5. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:2204: DB::QueryAnalyzer::resolveMatcher(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000001403b351 6. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3801: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000014019d28 7. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3980: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000014018e31 8. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:4304: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000014042fa7 9. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5605: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000014013749 10. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000140127f9 11. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000014011fce 12. /build/src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000001406ce8a 13. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000014973b42 14. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000001497268d 15. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000014974d24 16. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001492924b 17. /build/src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88641 18. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 19. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 20. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 21. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 22. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 23. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 24. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 25. ? @ 0x00007fbc6213eac3 26. ? @ 0x00007fbc621d0850 2025.07.28 11:58:05.754187 [ 5747 ] {4fe13628-48cd-4429-bc8d-cad3d51530cb} executeQuery: Code: 47. DB::Exception: Qualified matcher t.* does not find table. In scope t1 AS (SELECT t.* FROM numbers(1)). (UNKNOWN_IDENTIFIER) (version 25.3.6.10636.altinitytest (altinity build)) (from [::1]:38242) (comment: 03356_analyzer_qualified_matcher_error.sql) (query 5, line 29) (in query: WITH t as (SELECT sum(number) as x FROM numbers(10)), t1 as (SELECT t.* FROM numbers(1)) SELECT * FROM t1;), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000a06a8eb 4. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:1882: DB::QueryAnalyzer::resolveQualifiedMatcher(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000001402dd71 5. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:2204: DB::QueryAnalyzer::resolveMatcher(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000001403b351 6. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3801: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000014019d28 7. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3980: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000014018e31 8. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:4304: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000014042fa7 9. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5605: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000014013749 10. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3870: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x00000000140199de 11. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5334: DB::QueryAnalyzer::resolveQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&) @ 0x00000000140454b0 12. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5597: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000140136f0 13. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000140127f9 14. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000014011fce 15. /build/src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000001406ce8a 16. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000014973b42 17. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000001497268d 18. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000014974d24 19. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001492924b 20. /build/src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88641 21. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 22. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 23. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 24. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 25. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 26. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 27. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 28. ? @ 0x00007fbc6213eac3 29. ? @ 0x00007fbc621d0850 2025.07.28 11:58:05.763357 [ 5747 ] {} TCPHandler: Code: 47. DB::Exception: Qualified matcher t.* does not find table. In scope t1 AS (SELECT t.* FROM numbers(1)). (UNKNOWN_IDENTIFIER), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000a06a8eb 4. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:1882: DB::QueryAnalyzer::resolveQualifiedMatcher(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000001402dd71 5. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:2204: DB::QueryAnalyzer::resolveMatcher(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000001403b351 6. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3801: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000014019d28 7. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3980: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000014018e31 8. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:4304: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000014042fa7 9. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5605: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000014013749 10. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3870: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x00000000140199de 11. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5334: DB::QueryAnalyzer::resolveQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&) @ 0x00000000140454b0 12. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5597: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000140136f0 13. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000140127f9 14. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000014011fce 15. /build/src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000001406ce8a 16. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000014973b42 17. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000001497268d 18. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000014974d24 19. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001492924b 20. /build/src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88641 21. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 22. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 23. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 24. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 25. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 26. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 27. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 28. ? @ 0x00007fbc6213eac3 29. ? @ 0x00007fbc621d0850 2025.07.28 11:58:05.961509 [ 3974 ] {} test_13.rmt2 (7f9b740d-015c-470e-8cc6-8ba33be0dc63): auto DB::StorageReplicatedMergeTree::processQueueEntry(ReplicatedMergeTreeQueue::SelectedEntryPtr)::(anonymous class)::operator()(LogEntryPtr &) const: Code: 86. DB::HTTPException: Received error from remote server http://146b4357c08d:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Ftest%2F01165%2Ftest_13%2Frmt%2Freplicas%2F1&part=20250728_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.6.10636.altinitytest (altinity build)) '. (RECEIVED_ERROR_FROM_REMOTE_IO_SERVER), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.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 const&, int&&, String const&, unsigned long&&, String const&) @ 0x000000000feda8d9 4. /build/src/IO/HTTPCommon.cpp:104: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x000000000feda6e2 5. /build/src/IO/HTTPCommon.cpp:93: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x000000000feda537 6. /build/src/IO/ReadWriteBufferFromHTTP.cpp:277: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x000000001184a4c4 7. /build/src/IO/ReadWriteBufferFromHTTP.cpp:285: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x000000001184a615 8. /build/src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x000000001184ae59 9. /build/src/IO/ReadWriteBufferFromHTTP.cpp:472: void std::__function::__policy_invoker::__call_impl[abi:se190107]>(std::__function::__policy_storage const*) @ 0x000000001184cedd 10. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001184858b 11. /build/src/IO/ReadWriteBufferFromHTTP.cpp:465: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x000000001184bf0b 12. /build/src/IO/ReadBuffer.h:60: DB::ReadBuffer::next() @ 0x000000000a148c7b 13. /build/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) @ 0x0000000011849fb2 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]>&)>&, 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&) @ 0x0000000011841980 15. /build/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) @ 0x000000001621208e 16. /build/src/Storages/StorageReplicatedMergeTree.cpp:5228: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl[abi:se190107] const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000015f9a5fe 17. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000015ed8bfd 18. /build/src/Storages/StorageReplicatedMergeTree.cpp:2514: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x0000000015ec9aab 19. /build/src/Storages/StorageReplicatedMergeTree.cpp:2349: DB::StorageReplicatedMergeTree::executeLogEntry(DB::ReplicatedMergeTreeLogEntry&) @ 0x0000000015eba91b 20. /build/src/Storages/StorageReplicatedMergeTree.cpp:3876: bool std::__function::__policy_invoker&)>::__call_impl[abi:se190107])::$_1, bool (std::shared_ptr&)>>(std::__function::__policy_storage const*, std::shared_ptr&) @ 0x0000000015f9837e 21. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000165d6fc3 22. /build/src/Storages/StorageReplicatedMergeTree.cpp:3872: DB::StorageReplicatedMergeTree::processQueueEntry(std::shared_ptr) @ 0x0000000015efc18a 23. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001624c1b2 24. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000162f9c70 25. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x00000000162fa55a 26. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc6653 27. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000000fccc4c3 28. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc3d92 29. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fcca080 30. ? @ 0x00007fbc6213eac3 31. ? @ 0x00007fbc621d0850 (version 25.3.6.10636.altinitytest (altinity build)) 2025.07.28 11:58:06.038997 [ 17207 ] {3e42b854-8e37-40ef-b977-28feb62c952c} executeQuery: Code: 57. DB::Exception: Table test_f2gu8wn8.tab already exists. (TABLE_ALREADY_EXISTS) (version 25.3.6.10636.altinitytest (altinity build)) (from [::1]:38104) (comment: 01889_key_condition_function_chains.sql) (query 20, line 27) (in query: CREATE TABLE tab (`x` Int32, `y` Int32) ENGINE = MergeTree PARTITION BY ((x + y) + 1) * 2 ORDER BY tuple() SETTINGS index_granularity = 22391, min_bytes_for_wide_part = 1073741824, ratio_of_defaults_for_sparse_serialization = 1., replace_long_file_name_to_hash = false, max_file_name_length = 36, min_bytes_for_full_part_storage = 510417787, compact_parts_max_bytes_to_buffer = 253732747, compact_parts_max_granules_to_buffer = 226, compact_parts_merge_max_bytes_to_prefetch_part = 16314689, merge_max_block_size = 13781, 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 = 100, min_merge_bytes_to_use_direct_io = 6776310884, index_granularity_bytes = 7343261, use_const_adaptive_granularity = true, enable_index_granularity_compression = true, concurrent_part_removal_threshold = 94, allow_vertical_merges_from_compact_to_wide_parts = true, enable_block_number_column = false, enable_block_offset_column = false, cache_populated_by_fetch = false, marks_compress_block_size = 51325, primary_key_compress_block_size = 68164, 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. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000a06a8eb 4. /build/src/Interpreters/InterpreterCreateQuery.cpp:1824: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x0000000014901d53 5. /build/src/Interpreters/InterpreterCreateQuery.cpp:1743: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000148f9aa9 6. /build/src/Interpreters/InterpreterCreateQuery.cpp:2352: DB::InterpreterCreateQuery::execute() @ 0x0000000014905a41 7. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88dc9 8. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 9. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 10. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 11. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 12. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 13. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 14. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 15. ? @ 0x00007fbc6213eac3 16. ? @ 0x00007fbc621d0850 2025.07.28 11:58:06.044660 [ 17207 ] {} TCPHandler: Code: 57. DB::Exception: Table test_f2gu8wn8.tab already exists. (TABLE_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000a06a8eb 4. /build/src/Interpreters/InterpreterCreateQuery.cpp:1824: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x0000000014901d53 5. /build/src/Interpreters/InterpreterCreateQuery.cpp:1743: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000148f9aa9 6. /build/src/Interpreters/InterpreterCreateQuery.cpp:2352: DB::InterpreterCreateQuery::execute() @ 0x0000000014905a41 7. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88dc9 8. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 9. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 10. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 11. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 12. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 13. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 14. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 15. ? @ 0x00007fbc6213eac3 16. ? @ 0x00007fbc621d0850 2025.07.28 11:58:06.678789 [ 3977 ] {} test_13.rmt2 (7f9b740d-015c-470e-8cc6-8ba33be0dc63): auto DB::StorageReplicatedMergeTree::processQueueEntry(ReplicatedMergeTreeQueue::SelectedEntryPtr)::(anonymous class)::operator()(LogEntryPtr &) const: Code: 86. DB::HTTPException: Received error from remote server http://146b4357c08d:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Ftest%2F01165%2Ftest_13%2Frmt%2Freplicas%2F1&part=20250728_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.6.10636.altinitytest (altinity build)) '. (RECEIVED_ERROR_FROM_REMOTE_IO_SERVER), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.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 const&, int&&, String const&, unsigned long&&, String const&) @ 0x000000000feda8d9 4. /build/src/IO/HTTPCommon.cpp:104: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x000000000feda6e2 5. /build/src/IO/HTTPCommon.cpp:93: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x000000000feda537 6. /build/src/IO/ReadWriteBufferFromHTTP.cpp:277: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x000000001184a4c4 7. /build/src/IO/ReadWriteBufferFromHTTP.cpp:285: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x000000001184a615 8. /build/src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x000000001184ae59 9. /build/src/IO/ReadWriteBufferFromHTTP.cpp:472: void std::__function::__policy_invoker::__call_impl[abi:se190107]>(std::__function::__policy_storage const*) @ 0x000000001184cedd 10. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001184858b 11. /build/src/IO/ReadWriteBufferFromHTTP.cpp:465: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x000000001184bf0b 12. /build/src/IO/ReadBuffer.h:60: DB::ReadBuffer::next() @ 0x000000000a148c7b 13. /build/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) @ 0x0000000011849fb2 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]>&)>&, 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&) @ 0x0000000011841980 15. /build/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) @ 0x000000001621208e 16. /build/src/Storages/StorageReplicatedMergeTree.cpp:5228: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl[abi:se190107] const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000015f9a5fe 17. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000015ed8bfd 18. /build/src/Storages/StorageReplicatedMergeTree.cpp:2514: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x0000000015ec9aab 19. /build/src/Storages/StorageReplicatedMergeTree.cpp:2349: DB::StorageReplicatedMergeTree::executeLogEntry(DB::ReplicatedMergeTreeLogEntry&) @ 0x0000000015eba91b 20. /build/src/Storages/StorageReplicatedMergeTree.cpp:3876: bool std::__function::__policy_invoker&)>::__call_impl[abi:se190107])::$_1, bool (std::shared_ptr&)>>(std::__function::__policy_storage const*, std::shared_ptr&) @ 0x0000000015f9837e 21. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000165d6fc3 22. /build/src/Storages/StorageReplicatedMergeTree.cpp:3872: DB::StorageReplicatedMergeTree::processQueueEntry(std::shared_ptr) @ 0x0000000015efc18a 23. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001624c1b2 24. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000162f9c70 25. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x00000000162fa55a 26. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc6653 27. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000000fccc4c3 28. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc3d92 29. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fcca080 30. ? @ 0x00007fbc6213eac3 31. ? @ 0x00007fbc621d0850 (version 25.3.6.10636.altinitytest (altinity build)) 2025.07.28 11:58:07.300871 [ 3972 ] {} test_13.rmt2 (7f9b740d-015c-470e-8cc6-8ba33be0dc63): auto DB::StorageReplicatedMergeTree::processQueueEntry(ReplicatedMergeTreeQueue::SelectedEntryPtr)::(anonymous class)::operator()(LogEntryPtr &) const: Code: 86. DB::HTTPException: Received error from remote server http://146b4357c08d:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Ftest%2F01165%2Ftest_13%2Frmt%2Freplicas%2F1&part=20250728_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.6.10636.altinitytest (altinity build)) '. (RECEIVED_ERROR_FROM_REMOTE_IO_SERVER), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.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 const&, int&&, String const&, unsigned long&&, String const&) @ 0x000000000feda8d9 4. /build/src/IO/HTTPCommon.cpp:104: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x000000000feda6e2 5. /build/src/IO/HTTPCommon.cpp:93: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x000000000feda537 6. /build/src/IO/ReadWriteBufferFromHTTP.cpp:277: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x000000001184a4c4 7. /build/src/IO/ReadWriteBufferFromHTTP.cpp:285: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x000000001184a615 8. /build/src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x000000001184ae59 9. /build/src/IO/ReadWriteBufferFromHTTP.cpp:472: void std::__function::__policy_invoker::__call_impl[abi:se190107]>(std::__function::__policy_storage const*) @ 0x000000001184cedd 10. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001184858b 11. /build/src/IO/ReadWriteBufferFromHTTP.cpp:465: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x000000001184bf0b 12. /build/src/IO/ReadBuffer.h:60: DB::ReadBuffer::next() @ 0x000000000a148c7b 13. /build/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) @ 0x0000000011849fb2 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]>&)>&, 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&) @ 0x0000000011841980 15. /build/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) @ 0x000000001621208e 16. /build/src/Storages/StorageReplicatedMergeTree.cpp:5228: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl[abi:se190107] const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000015f9a5fe 17. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000015ed8bfd 18. /build/src/Storages/StorageReplicatedMergeTree.cpp:2514: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x0000000015ec9aab 19. /build/src/Storages/StorageReplicatedMergeTree.cpp:2349: DB::StorageReplicatedMergeTree::executeLogEntry(DB::ReplicatedMergeTreeLogEntry&) @ 0x0000000015eba91b 20. /build/src/Storages/StorageReplicatedMergeTree.cpp:3876: bool std::__function::__policy_invoker&)>::__call_impl[abi:se190107])::$_1, bool (std::shared_ptr&)>>(std::__function::__policy_storage const*, std::shared_ptr&) @ 0x0000000015f9837e 21. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000165d6fc3 22. /build/src/Storages/StorageReplicatedMergeTree.cpp:3872: DB::StorageReplicatedMergeTree::processQueueEntry(std::shared_ptr) @ 0x0000000015efc18a 23. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001624c1b2 24. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000162f9c70 25. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x00000000162fa55a 26. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc6653 27. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000000fccc4c3 28. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc3d92 29. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fcca080 30. ? @ 0x00007fbc6213eac3 31. ? @ 0x00007fbc621d0850 (version 25.3.6.10636.altinitytest (altinity build)) 2025.07.28 11:58:07.476750 [ 7625 ] {83495784-068c-4e2e-af22-0d4421453f29} 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.6.10636.altinitytest (altinity build)) (from [::ffff:127.0.0.1]:44052) (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. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, char const*&, ReadableSize&&, ReadableSize&&) @ 0x0000000013bd4eeb 4. /build/src/QueryPipeline/SizeLimits.cpp:43: DB::SizeLimits::check(unsigned long, unsigned long, char const*, int, int) const @ 0x0000000013bd48a1 5. /build/src/Processors/Transforms/LimitsCheckingTransform.cpp:45: DB::LimitsCheckingTransform::transform(DB::Chunk&) @ 0x0000000016c1d2fb 6. /build/src/Processors/ISimpleTransform.h:33: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000011a9a453 7. /build/src/Processors/ISimpleTransform.cpp:89: DB::ISimpleTransform::work() @ 0x000000001699fca0 8. /build/src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x00000000169bd00f 9. /build/src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x00000000169b2105 10. /build/src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeSingleThread(unsigned long) @ 0x00000000169b23be 11. /build/src/Processors/Executors/PipelineExecutor.cpp:454: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x00000000169b0be7 12. /build/src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x00000000169b03f4 13. /build/src/Processors/Executors/CompletedPipelineExecutor.cpp:105: DB::CompletedPipelineExecutor::execute() @ 0x00000000169af3c4 14. /build/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&)>) @ 0x0000000014c8d123 15. /build/src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000001686da12 16. /build/src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x0000000016870807 17. /build/src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x0000000016907e99 18. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 19. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 20. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 21. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 22. ? @ 0x00007fbc6213eac3 23. ? @ 0x00007fbc621d0850 2025.07.28 11:58:07.479718 [ 7625 ] {83495784-068c-4e2e-af22-0d4421453f29} 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. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, char const*&, ReadableSize&&, ReadableSize&&) @ 0x0000000013bd4eeb 4. /build/src/QueryPipeline/SizeLimits.cpp:43: DB::SizeLimits::check(unsigned long, unsigned long, char const*, int, int) const @ 0x0000000013bd48a1 5. /build/src/Processors/Transforms/LimitsCheckingTransform.cpp:45: DB::LimitsCheckingTransform::transform(DB::Chunk&) @ 0x0000000016c1d2fb 6. /build/src/Processors/ISimpleTransform.h:33: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000011a9a453 7. /build/src/Processors/ISimpleTransform.cpp:89: DB::ISimpleTransform::work() @ 0x000000001699fca0 8. /build/src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x00000000169bd00f 9. /build/src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x00000000169b2105 10. /build/src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeSingleThread(unsigned long) @ 0x00000000169b23be 11. /build/src/Processors/Executors/PipelineExecutor.cpp:454: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x00000000169b0be7 12. /build/src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x00000000169b03f4 13. /build/src/Processors/Executors/CompletedPipelineExecutor.cpp:105: DB::CompletedPipelineExecutor::execute() @ 0x00000000169af3c4 14. /build/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&)>) @ 0x0000000014c8d123 15. /build/src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000001686da12 16. /build/src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x0000000016870807 17. /build/src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x0000000016907e99 18. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 19. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 20. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 21. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 22. ? @ 0x00007fbc6213eac3 23. ? @ 0x00007fbc621d0850 (version 25.3.6.10636.altinitytest (altinity build)) 2025.07.28 11:58:07.933520 [ 3965 ] {} test_13.rmt2 (7f9b740d-015c-470e-8cc6-8ba33be0dc63): auto DB::StorageReplicatedMergeTree::processQueueEntry(ReplicatedMergeTreeQueue::SelectedEntryPtr)::(anonymous class)::operator()(LogEntryPtr &) const: Code: 86. DB::HTTPException: Received error from remote server http://146b4357c08d:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Ftest%2F01165%2Ftest_13%2Frmt%2Freplicas%2F1&part=20250728_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.6.10636.altinitytest (altinity build)) '. (RECEIVED_ERROR_FROM_REMOTE_IO_SERVER), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.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 const&, int&&, String const&, unsigned long&&, String const&) @ 0x000000000feda8d9 4. /build/src/IO/HTTPCommon.cpp:104: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x000000000feda6e2 5. /build/src/IO/HTTPCommon.cpp:93: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x000000000feda537 6. /build/src/IO/ReadWriteBufferFromHTTP.cpp:277: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x000000001184a4c4 7. /build/src/IO/ReadWriteBufferFromHTTP.cpp:285: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x000000001184a615 8. /build/src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x000000001184ae59 9. /build/src/IO/ReadWriteBufferFromHTTP.cpp:472: void std::__function::__policy_invoker::__call_impl[abi:se190107]>(std::__function::__policy_storage const*) @ 0x000000001184cedd 10. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001184858b 11. /build/src/IO/ReadWriteBufferFromHTTP.cpp:465: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x000000001184bf0b 12. /build/src/IO/ReadBuffer.h:60: DB::ReadBuffer::next() @ 0x000000000a148c7b 13. /build/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) @ 0x0000000011849fb2 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]>&)>&, 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&) @ 0x0000000011841980 15. /build/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) @ 0x000000001621208e 16. /build/src/Storages/StorageReplicatedMergeTree.cpp:5228: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl[abi:se190107] const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000015f9a5fe 17. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000015ed8bfd 18. /build/src/Storages/StorageReplicatedMergeTree.cpp:2514: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x0000000015ec9aab 19. /build/src/Storages/StorageReplicatedMergeTree.cpp:2349: DB::StorageReplicatedMergeTree::executeLogEntry(DB::ReplicatedMergeTreeLogEntry&) @ 0x0000000015eba91b 20. /build/src/Storages/StorageReplicatedMergeTree.cpp:3876: bool std::__function::__policy_invoker&)>::__call_impl[abi:se190107])::$_1, bool (std::shared_ptr&)>>(std::__function::__policy_storage const*, std::shared_ptr&) @ 0x0000000015f9837e 21. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000165d6fc3 22. /build/src/Storages/StorageReplicatedMergeTree.cpp:3872: DB::StorageReplicatedMergeTree::processQueueEntry(std::shared_ptr) @ 0x0000000015efc18a 23. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001624c1b2 24. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000162f9c70 25. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x00000000162fa55a 26. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc6653 27. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000000fccc4c3 28. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc3d92 29. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fcca080 30. ? @ 0x00007fbc6213eac3 31. ? @ 0x00007fbc621d0850 (version 25.3.6.10636.altinitytest (altinity build)) 2025.07.28 11:58:08.375535 [ 3976 ] {} test_13.rmt2 (7f9b740d-015c-470e-8cc6-8ba33be0dc63): auto DB::StorageReplicatedMergeTree::processQueueEntry(ReplicatedMergeTreeQueue::SelectedEntryPtr)::(anonymous class)::operator()(LogEntryPtr &) const: Code: 86. DB::HTTPException: Received error from remote server http://146b4357c08d:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Ftest%2F01165%2Ftest_13%2Frmt%2Freplicas%2F1&part=20250728_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.6.10636.altinitytest (altinity build)) '. (RECEIVED_ERROR_FROM_REMOTE_IO_SERVER), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.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 const&, int&&, String const&, unsigned long&&, String const&) @ 0x000000000feda8d9 4. /build/src/IO/HTTPCommon.cpp:104: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x000000000feda6e2 5. /build/src/IO/HTTPCommon.cpp:93: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x000000000feda537 6. /build/src/IO/ReadWriteBufferFromHTTP.cpp:277: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x000000001184a4c4 7. /build/src/IO/ReadWriteBufferFromHTTP.cpp:285: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x000000001184a615 8. /build/src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x000000001184ae59 9. /build/src/IO/ReadWriteBufferFromHTTP.cpp:472: void std::__function::__policy_invoker::__call_impl[abi:se190107]>(std::__function::__policy_storage const*) @ 0x000000001184cedd 10. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001184858b 11. /build/src/IO/ReadWriteBufferFromHTTP.cpp:465: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x000000001184bf0b 12. /build/src/IO/ReadBuffer.h:60: DB::ReadBuffer::next() @ 0x000000000a148c7b 13. /build/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) @ 0x0000000011849fb2 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]>&)>&, 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&) @ 0x0000000011841980 15. /build/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) @ 0x000000001621208e 16. /build/src/Storages/StorageReplicatedMergeTree.cpp:5228: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl[abi:se190107] const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000015f9a5fe 17. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000015ed8bfd 18. /build/src/Storages/StorageReplicatedMergeTree.cpp:2514: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x0000000015ec9aab 19. /build/src/Storages/StorageReplicatedMergeTree.cpp:2349: DB::StorageReplicatedMergeTree::executeLogEntry(DB::ReplicatedMergeTreeLogEntry&) @ 0x0000000015eba91b 20. /build/src/Storages/StorageReplicatedMergeTree.cpp:3876: bool std::__function::__policy_invoker&)>::__call_impl[abi:se190107])::$_1, bool (std::shared_ptr&)>>(std::__function::__policy_storage const*, std::shared_ptr&) @ 0x0000000015f9837e 21. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000165d6fc3 22. /build/src/Storages/StorageReplicatedMergeTree.cpp:3872: DB::StorageReplicatedMergeTree::processQueueEntry(std::shared_ptr) @ 0x0000000015efc18a 23. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001624c1b2 24. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000162f9c70 25. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x00000000162fa55a 26. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc6653 27. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000000fccc4c3 28. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc3d92 29. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fcca080 30. ? @ 0x00007fbc6213eac3 31. ? @ 0x00007fbc621d0850 (version 25.3.6.10636.altinitytest (altinity build)) 2025.07.28 11:58:08.919905 [ 7625 ] {1a8d79e2-a0a7-424f-b64b-abfea6ee0b58} 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.6.10636.altinitytest (altinity build)) (from [::ffff:127.0.0.1]:44062) (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. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, char const*&, ReadableSize&&, ReadableSize&&) @ 0x0000000013bd4eeb 4. /build/src/QueryPipeline/SizeLimits.cpp:43: DB::SizeLimits::check(unsigned long, unsigned long, char const*, int, int) const @ 0x0000000013bd48a1 5. /build/src/Processors/Transforms/LimitsCheckingTransform.cpp:45: DB::LimitsCheckingTransform::transform(DB::Chunk&) @ 0x0000000016c1d2fb 6. /build/src/Processors/ISimpleTransform.h:33: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000011a9a453 7. /build/src/Processors/ISimpleTransform.cpp:89: DB::ISimpleTransform::work() @ 0x000000001699fca0 8. /build/src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x00000000169bd00f 9. /build/src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x00000000169b2105 10. /build/src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeSingleThread(unsigned long) @ 0x00000000169b23be 11. /build/src/Processors/Executors/PipelineExecutor.cpp:454: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x00000000169b0be7 12. /build/src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x00000000169b03f4 13. /build/src/Processors/Executors/CompletedPipelineExecutor.cpp:105: DB::CompletedPipelineExecutor::execute() @ 0x00000000169af3c4 14. /build/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&)>) @ 0x0000000014c8d123 15. /build/src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000001686da12 16. /build/src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x0000000016870807 17. /build/src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x0000000016907e99 18. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 19. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 20. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 21. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 22. ? @ 0x00007fbc6213eac3 23. ? @ 0x00007fbc621d0850 2025.07.28 11:58:08.932357 [ 7625 ] {1a8d79e2-a0a7-424f-b64b-abfea6ee0b58} 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. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, char const*&, ReadableSize&&, ReadableSize&&) @ 0x0000000013bd4eeb 4. /build/src/QueryPipeline/SizeLimits.cpp:43: DB::SizeLimits::check(unsigned long, unsigned long, char const*, int, int) const @ 0x0000000013bd48a1 5. /build/src/Processors/Transforms/LimitsCheckingTransform.cpp:45: DB::LimitsCheckingTransform::transform(DB::Chunk&) @ 0x0000000016c1d2fb 6. /build/src/Processors/ISimpleTransform.h:33: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000011a9a453 7. /build/src/Processors/ISimpleTransform.cpp:89: DB::ISimpleTransform::work() @ 0x000000001699fca0 8. /build/src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x00000000169bd00f 9. /build/src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x00000000169b2105 10. /build/src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeSingleThread(unsigned long) @ 0x00000000169b23be 11. /build/src/Processors/Executors/PipelineExecutor.cpp:454: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x00000000169b0be7 12. /build/src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x00000000169b03f4 13. /build/src/Processors/Executors/CompletedPipelineExecutor.cpp:105: DB::CompletedPipelineExecutor::execute() @ 0x00000000169af3c4 14. /build/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&)>) @ 0x0000000014c8d123 15. /build/src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000001686da12 16. /build/src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x0000000016870807 17. /build/src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x0000000016907e99 18. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 19. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 20. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 21. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 22. ? @ 0x00007fbc6213eac3 23. ? @ 0x00007fbc621d0850 (version 25.3.6.10636.altinitytest (altinity build)) 2025.07.28 11:58:09.215124 [ 3963 ] {} test_13.rmt2 (7f9b740d-015c-470e-8cc6-8ba33be0dc63): auto DB::StorageReplicatedMergeTree::processQueueEntry(ReplicatedMergeTreeQueue::SelectedEntryPtr)::(anonymous class)::operator()(LogEntryPtr &) const: Code: 86. DB::HTTPException: Received error from remote server http://146b4357c08d:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Ftest%2F01165%2Ftest_13%2Frmt%2Freplicas%2F1&part=20250728_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.6.10636.altinitytest (altinity build)) '. (RECEIVED_ERROR_FROM_REMOTE_IO_SERVER), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.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 const&, int&&, String const&, unsigned long&&, String const&) @ 0x000000000feda8d9 4. /build/src/IO/HTTPCommon.cpp:104: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x000000000feda6e2 5. /build/src/IO/HTTPCommon.cpp:93: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x000000000feda537 6. /build/src/IO/ReadWriteBufferFromHTTP.cpp:277: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x000000001184a4c4 7. /build/src/IO/ReadWriteBufferFromHTTP.cpp:285: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x000000001184a615 8. /build/src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x000000001184ae59 9. /build/src/IO/ReadWriteBufferFromHTTP.cpp:472: void std::__function::__policy_invoker::__call_impl[abi:se190107]>(std::__function::__policy_storage const*) @ 0x000000001184cedd 10. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001184858b 11. /build/src/IO/ReadWriteBufferFromHTTP.cpp:465: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x000000001184bf0b 12. /build/src/IO/ReadBuffer.h:60: DB::ReadBuffer::next() @ 0x000000000a148c7b 13. /build/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) @ 0x0000000011849fb2 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]>&)>&, 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&) @ 0x0000000011841980 15. /build/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) @ 0x000000001621208e 16. /build/src/Storages/StorageReplicatedMergeTree.cpp:5228: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl[abi:se190107] const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000015f9a5fe 17. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000015ed8bfd 18. /build/src/Storages/StorageReplicatedMergeTree.cpp:2514: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x0000000015ec9aab 19. /build/src/Storages/StorageReplicatedMergeTree.cpp:2349: DB::StorageReplicatedMergeTree::executeLogEntry(DB::ReplicatedMergeTreeLogEntry&) @ 0x0000000015eba91b 20. /build/src/Storages/StorageReplicatedMergeTree.cpp:3876: bool std::__function::__policy_invoker&)>::__call_impl[abi:se190107])::$_1, bool (std::shared_ptr&)>>(std::__function::__policy_storage const*, std::shared_ptr&) @ 0x0000000015f9837e 21. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000165d6fc3 22. /build/src/Storages/StorageReplicatedMergeTree.cpp:3872: DB::StorageReplicatedMergeTree::processQueueEntry(std::shared_ptr) @ 0x0000000015efc18a 23. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001624c1b2 24. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000162f9c70 25. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x00000000162fa55a 26. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc6653 27. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000000fccc4c3 28. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc3d92 29. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fcca080 30. ? @ 0x00007fbc6213eac3 31. ? @ 0x00007fbc621d0850 (version 25.3.6.10636.altinitytest (altinity build)) 2025.07.28 11:58:09.402285 [ 3960 ] {} test_13.rmt2 (7f9b740d-015c-470e-8cc6-8ba33be0dc63): auto DB::StorageReplicatedMergeTree::processQueueEntry(ReplicatedMergeTreeQueue::SelectedEntryPtr)::(anonymous class)::operator()(LogEntryPtr &) const: Code: 86. DB::HTTPException: Received error from remote server http://146b4357c08d:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Ftest%2F01165%2Ftest_13%2Frmt%2Freplicas%2F1&part=20250728_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.6.10636.altinitytest (altinity build)) '. (RECEIVED_ERROR_FROM_REMOTE_IO_SERVER), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.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 const&, int&&, String const&, unsigned long&&, String const&) @ 0x000000000feda8d9 4. /build/src/IO/HTTPCommon.cpp:104: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x000000000feda6e2 5. /build/src/IO/HTTPCommon.cpp:93: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x000000000feda537 6. /build/src/IO/ReadWriteBufferFromHTTP.cpp:277: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x000000001184a4c4 7. /build/src/IO/ReadWriteBufferFromHTTP.cpp:285: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x000000001184a615 8. /build/src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x000000001184ae59 9. /build/src/IO/ReadWriteBufferFromHTTP.cpp:472: void std::__function::__policy_invoker::__call_impl[abi:se190107]>(std::__function::__policy_storage const*) @ 0x000000001184cedd 10. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001184858b 11. /build/src/IO/ReadWriteBufferFromHTTP.cpp:465: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x000000001184bf0b 12. /build/src/IO/ReadBuffer.h:60: DB::ReadBuffer::next() @ 0x000000000a148c7b 13. /build/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) @ 0x0000000011849fb2 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]>&)>&, 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&) @ 0x0000000011841980 15. /build/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) @ 0x000000001621208e 16. /build/src/Storages/StorageReplicatedMergeTree.cpp:5228: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl[abi:se190107] const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000015f9a5fe 17. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000015ed8bfd 18. /build/src/Storages/StorageReplicatedMergeTree.cpp:2514: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x0000000015ec9aab 19. /build/src/Storages/StorageReplicatedMergeTree.cpp:2349: DB::StorageReplicatedMergeTree::executeLogEntry(DB::ReplicatedMergeTreeLogEntry&) @ 0x0000000015eba91b 20. /build/src/Storages/StorageReplicatedMergeTree.cpp:3876: bool std::__function::__policy_invoker&)>::__call_impl[abi:se190107])::$_1, bool (std::shared_ptr&)>>(std::__function::__policy_storage const*, std::shared_ptr&) @ 0x0000000015f9837e 21. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000165d6fc3 22. /build/src/Storages/StorageReplicatedMergeTree.cpp:3872: DB::StorageReplicatedMergeTree::processQueueEntry(std::shared_ptr) @ 0x0000000015efc18a 23. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001624c1b2 24. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000162f9c70 25. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x00000000162fa55a 26. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc6653 27. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000000fccc4c3 28. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc3d92 29. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fcca080 30. ? @ 0x00007fbc6213eac3 31. ? @ 0x00007fbc621d0850 (version 25.3.6.10636.altinitytest (altinity build)) 2025.07.28 11:58:09.517290 [ 17208 ] {ea966db2-1b21-48c3-9da6-1c993d6d0ea5} executeQuery: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION) (version 25.3.6.10636.altinitytest (altinity build)) (from [::1]:38370) (comment: 00940_order_by_read_in_order_query_plan.sql) (query 1, line 1) (in query: SET optimize_read_in_order = 1, query_plan_read_in_order = 1, enable_analyzer = 0;), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x000000000c25bc4b 4. /build/src/Access/SettingsConstraints.cpp:343: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000138596e3 5. /build/src/Access/SettingsConstraints.cpp:300: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000013858faf 6. /build/src/Access/SettingsConstraints.cpp:194: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges const&, DB::SettingSource) const @ 0x00000000138591b3 7. /build/src/Interpreters/Context.cpp:2722: DB::Context::checkSettingsConstraints(DB::SettingsChanges const&, DB::SettingSource) @ 0x0000000014436509 8. /build/src/Interpreters/InterpreterSetQuery.cpp:28: DB::InterpreterSetQuery::execute() @ 0x00000000149e240a 9. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88dc9 10. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 11. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 12. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 13. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 14. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 16. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 17. ? @ 0x00007fbc6213eac3 18. ? @ 0x00007fbc621d0850 2025.07.28 11:58:09.536894 [ 17208 ] {} 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. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x000000000c25bc4b 4. /build/src/Access/SettingsConstraints.cpp:343: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000138596e3 5. /build/src/Access/SettingsConstraints.cpp:300: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000013858faf 6. /build/src/Access/SettingsConstraints.cpp:194: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges const&, DB::SettingSource) const @ 0x00000000138591b3 7. /build/src/Interpreters/Context.cpp:2722: DB::Context::checkSettingsConstraints(DB::SettingsChanges const&, DB::SettingSource) @ 0x0000000014436509 8. /build/src/Interpreters/InterpreterSetQuery.cpp:28: DB::InterpreterSetQuery::execute() @ 0x00000000149e240a 9. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88dc9 10. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 11. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 12. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 13. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 14. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 16. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 17. ? @ 0x00007fbc6213eac3 18. ? @ 0x00007fbc621d0850 2025.07.28 11:58:09.613730 [ 3964 ] {} test_13.rmt2 (7f9b740d-015c-470e-8cc6-8ba33be0dc63): auto DB::StorageReplicatedMergeTree::processQueueEntry(ReplicatedMergeTreeQueue::SelectedEntryPtr)::(anonymous class)::operator()(LogEntryPtr &) const: Code: 86. DB::HTTPException: Received error from remote server http://146b4357c08d:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Ftest%2F01165%2Ftest_13%2Frmt%2Freplicas%2F1&part=20250728_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.6.10636.altinitytest (altinity build)) '. (RECEIVED_ERROR_FROM_REMOTE_IO_SERVER), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.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 const&, int&&, String const&, unsigned long&&, String const&) @ 0x000000000feda8d9 4. /build/src/IO/HTTPCommon.cpp:104: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x000000000feda6e2 5. /build/src/IO/HTTPCommon.cpp:93: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x000000000feda537 6. /build/src/IO/ReadWriteBufferFromHTTP.cpp:277: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x000000001184a4c4 7. /build/src/IO/ReadWriteBufferFromHTTP.cpp:285: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x000000001184a615 8. /build/src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x000000001184ae59 9. /build/src/IO/ReadWriteBufferFromHTTP.cpp:472: void std::__function::__policy_invoker::__call_impl[abi:se190107]>(std::__function::__policy_storage const*) @ 0x000000001184cedd 10. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001184858b 11. /build/src/IO/ReadWriteBufferFromHTTP.cpp:465: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x000000001184bf0b 12. /build/src/IO/ReadBuffer.h:60: DB::ReadBuffer::next() @ 0x000000000a148c7b 13. /build/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) @ 0x0000000011849fb2 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]>&)>&, 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&) @ 0x0000000011841980 15. /build/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) @ 0x000000001621208e 16. /build/src/Storages/StorageReplicatedMergeTree.cpp:5228: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl[abi:se190107] const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000015f9a5fe 17. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000015ed8bfd 18. /build/src/Storages/StorageReplicatedMergeTree.cpp:2514: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x0000000015ec9aab 19. /build/src/Storages/StorageReplicatedMergeTree.cpp:2349: DB::StorageReplicatedMergeTree::executeLogEntry(DB::ReplicatedMergeTreeLogEntry&) @ 0x0000000015eba91b 20. /build/src/Storages/StorageReplicatedMergeTree.cpp:3876: bool std::__function::__policy_invoker&)>::__call_impl[abi:se190107])::$_1, bool (std::shared_ptr&)>>(std::__function::__policy_storage const*, std::shared_ptr&) @ 0x0000000015f9837e 21. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000165d6fc3 22. /build/src/Storages/StorageReplicatedMergeTree.cpp:3872: DB::StorageReplicatedMergeTree::processQueueEntry(std::shared_ptr) @ 0x0000000015efc18a 23. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001624c1b2 24. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000162f9c70 25. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x00000000162fa55a 26. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc6653 27. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000000fccc4c3 28. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc3d92 29. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fcca080 30. ? @ 0x00007fbc6213eac3 31. ? @ 0x00007fbc621d0850 (version 25.3.6.10636.altinitytest (altinity build)) 2025.07.28 11:58:09.874785 [ 4963 ] {} 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. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception>&, String>(int, FormatStringHelperImpl>&>::type, std::type_identity::type>, std::basic_string_view>&, String&&) @ 0x000000001385a5eb 4. /build/src/Access/SettingsConstraints.cpp:376: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000013859b18 5. /build/src/Access/SettingsConstraints.cpp:300: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000013858faf 6. /build/src/Access/SettingsConstraints.cpp:209: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000013859223 7. /build/src/Interpreters/Context.cpp:2690: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000014436134 8. /build/src/Interpreters/Context.cpp:2729: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x000000001443662b 9. /build/src/Server/HTTPHandler.cpp:457: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000001686d165 10. /build/src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x0000000016870807 11. /build/src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x0000000016907e99 12. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 13. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 14. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 15. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 16. ? @ 0x00007fbc6213eac3 17. ? @ 0x00007fbc621d0850 (version 25.3.6.10636.altinitytest (altinity build)) 2025.07.28 11:58:09.989227 [ 3961 ] {} test_13.rmt2 (7f9b740d-015c-470e-8cc6-8ba33be0dc63): auto DB::StorageReplicatedMergeTree::processQueueEntry(ReplicatedMergeTreeQueue::SelectedEntryPtr)::(anonymous class)::operator()(LogEntryPtr &) const: Code: 86. DB::HTTPException: Received error from remote server http://146b4357c08d:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Ftest%2F01165%2Ftest_13%2Frmt%2Freplicas%2F1&part=20250728_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.6.10636.altinitytest (altinity build)) '. (RECEIVED_ERROR_FROM_REMOTE_IO_SERVER), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.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 const&, int&&, String const&, unsigned long&&, String const&) @ 0x000000000feda8d9 4. /build/src/IO/HTTPCommon.cpp:104: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x000000000feda6e2 5. /build/src/IO/HTTPCommon.cpp:93: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x000000000feda537 6. /build/src/IO/ReadWriteBufferFromHTTP.cpp:277: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x000000001184a4c4 7. /build/src/IO/ReadWriteBufferFromHTTP.cpp:285: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x000000001184a615 8. /build/src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x000000001184ae59 9. /build/src/IO/ReadWriteBufferFromHTTP.cpp:472: void std::__function::__policy_invoker::__call_impl[abi:se190107]>(std::__function::__policy_storage const*) @ 0x000000001184cedd 10. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001184858b 11. /build/src/IO/ReadWriteBufferFromHTTP.cpp:465: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x000000001184bf0b 12. /build/src/IO/ReadBuffer.h:60: DB::ReadBuffer::next() @ 0x000000000a148c7b 13. /build/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) @ 0x0000000011849fb2 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]>&)>&, 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&) @ 0x0000000011841980 15. /build/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) @ 0x000000001621208e 16. /build/src/Storages/StorageReplicatedMergeTree.cpp:5228: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl[abi:se190107] const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000015f9a5fe 17. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000015ed8bfd 18. /build/src/Storages/StorageReplicatedMergeTree.cpp:2514: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x0000000015ec9aab 19. /build/src/Storages/StorageReplicatedMergeTree.cpp:2349: DB::StorageReplicatedMergeTree::executeLogEntry(DB::ReplicatedMergeTreeLogEntry&) @ 0x0000000015eba91b 20. /build/src/Storages/StorageReplicatedMergeTree.cpp:3876: bool std::__function::__policy_invoker&)>::__call_impl[abi:se190107])::$_1, bool (std::shared_ptr&)>>(std::__function::__policy_storage const*, std::shared_ptr&) @ 0x0000000015f9837e 21. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000165d6fc3 22. /build/src/Storages/StorageReplicatedMergeTree.cpp:3872: DB::StorageReplicatedMergeTree::processQueueEntry(std::shared_ptr) @ 0x0000000015efc18a 23. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001624c1b2 24. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000162f9c70 25. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x00000000162fa55a 26. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc6653 27. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000000fccc4c3 28. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc3d92 29. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fcca080 30. ? @ 0x00007fbc6213eac3 31. ? @ 0x00007fbc621d0850 (version 25.3.6.10636.altinitytest (altinity build)) 2025.07.28 11:58:10.569889 [ 3966 ] {} test_13.rmt2 (7f9b740d-015c-470e-8cc6-8ba33be0dc63): auto DB::StorageReplicatedMergeTree::processQueueEntry(ReplicatedMergeTreeQueue::SelectedEntryPtr)::(anonymous class)::operator()(LogEntryPtr &) const: Code: 86. DB::HTTPException: Received error from remote server http://146b4357c08d:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Ftest%2F01165%2Ftest_13%2Frmt%2Freplicas%2F1&part=20250728_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.6.10636.altinitytest (altinity build)) '. (RECEIVED_ERROR_FROM_REMOTE_IO_SERVER), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.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 const&, int&&, String const&, unsigned long&&, String const&) @ 0x000000000feda8d9 4. /build/src/IO/HTTPCommon.cpp:104: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x000000000feda6e2 5. /build/src/IO/HTTPCommon.cpp:93: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x000000000feda537 6. /build/src/IO/ReadWriteBufferFromHTTP.cpp:277: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x000000001184a4c4 7. /build/src/IO/ReadWriteBufferFromHTTP.cpp:285: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x000000001184a615 8. /build/src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x000000001184ae59 9. /build/src/IO/ReadWriteBufferFromHTTP.cpp:472: void std::__function::__policy_invoker::__call_impl[abi:se190107]>(std::__function::__policy_storage const*) @ 0x000000001184cedd 10. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001184858b 11. /build/src/IO/ReadWriteBufferFromHTTP.cpp:465: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x000000001184bf0b 12. /build/src/IO/ReadBuffer.h:60: DB::ReadBuffer::next() @ 0x000000000a148c7b 13. /build/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) @ 0x0000000011849fb2 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]>&)>&, 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&) @ 0x0000000011841980 15. /build/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) @ 0x000000001621208e 16. /build/src/Storages/StorageReplicatedMergeTree.cpp:5228: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl[abi:se190107] const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000015f9a5fe 17. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000015ed8bfd 18. /build/src/Storages/StorageReplicatedMergeTree.cpp:2514: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x0000000015ec9aab 19. /build/src/Storages/StorageReplicatedMergeTree.cpp:2349: DB::StorageReplicatedMergeTree::executeLogEntry(DB::ReplicatedMergeTreeLogEntry&) @ 0x0000000015eba91b 20. /build/src/Storages/StorageReplicatedMergeTree.cpp:3876: bool std::__function::__policy_invoker&)>::__call_impl[abi:se190107])::$_1, bool (std::shared_ptr&)>>(std::__function::__policy_storage const*, std::shared_ptr&) @ 0x0000000015f9837e 21. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000165d6fc3 22. /build/src/Storages/StorageReplicatedMergeTree.cpp:3872: DB::StorageReplicatedMergeTree::processQueueEntry(std::shared_ptr) @ 0x0000000015efc18a 23. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001624c1b2 24. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000162f9c70 25. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x00000000162fa55a 26. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc6653 27. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000000fccc4c3 28. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc3d92 29. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fcca080 30. ? @ 0x00007fbc6213eac3 31. ? @ 0x00007fbc621d0850 (version 25.3.6.10636.altinitytest (altinity build)) 2025.07.28 11:58:10.916300 [ 7625 ] {4c33d405-0f7e-4b88-9132-5777badcb8f2} 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.6.10636.altinitytest (altinity build)) (from [::ffff:127.0.0.1]:44070) (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. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, char const*&, ReadableSize&&, ReadableSize&&) @ 0x0000000013bd4eeb 4. /build/src/QueryPipeline/SizeLimits.cpp:43: DB::SizeLimits::check(unsigned long, unsigned long, char const*, int, int) const @ 0x0000000013bd48a1 5. /build/src/Processors/Transforms/LimitsCheckingTransform.cpp:45: DB::LimitsCheckingTransform::transform(DB::Chunk&) @ 0x0000000016c1d2fb 6. /build/src/Processors/ISimpleTransform.h:33: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000011a9a453 7. /build/src/Processors/ISimpleTransform.cpp:89: DB::ISimpleTransform::work() @ 0x000000001699fca0 8. /build/src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x00000000169bd00f 9. /build/src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x00000000169b2105 10. /build/src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeSingleThread(unsigned long) @ 0x00000000169b23be 11. /build/src/Processors/Executors/PipelineExecutor.cpp:454: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x00000000169b0be7 12. /build/src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x00000000169b03f4 13. /build/src/Processors/Executors/CompletedPipelineExecutor.cpp:105: DB::CompletedPipelineExecutor::execute() @ 0x00000000169af3c4 14. /build/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&)>) @ 0x0000000014c8d123 15. /build/src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000001686da12 16. /build/src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x0000000016870807 17. /build/src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x0000000016907e99 18. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 19. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 20. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 21. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 22. ? @ 0x00007fbc6213eac3 23. ? @ 0x00007fbc621d0850 2025.07.28 11:58:10.924235 [ 7625 ] {4c33d405-0f7e-4b88-9132-5777badcb8f2} 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. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, char const*&, ReadableSize&&, ReadableSize&&) @ 0x0000000013bd4eeb 4. /build/src/QueryPipeline/SizeLimits.cpp:43: DB::SizeLimits::check(unsigned long, unsigned long, char const*, int, int) const @ 0x0000000013bd48a1 5. /build/src/Processors/Transforms/LimitsCheckingTransform.cpp:45: DB::LimitsCheckingTransform::transform(DB::Chunk&) @ 0x0000000016c1d2fb 6. /build/src/Processors/ISimpleTransform.h:33: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000011a9a453 7. /build/src/Processors/ISimpleTransform.cpp:89: DB::ISimpleTransform::work() @ 0x000000001699fca0 8. /build/src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x00000000169bd00f 9. /build/src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x00000000169b2105 10. /build/src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeSingleThread(unsigned long) @ 0x00000000169b23be 11. /build/src/Processors/Executors/PipelineExecutor.cpp:454: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x00000000169b0be7 12. /build/src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x00000000169b03f4 13. /build/src/Processors/Executors/CompletedPipelineExecutor.cpp:105: DB::CompletedPipelineExecutor::execute() @ 0x00000000169af3c4 14. /build/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&)>) @ 0x0000000014c8d123 15. /build/src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000001686da12 16. /build/src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x0000000016870807 17. /build/src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x0000000016907e99 18. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 19. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 20. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 21. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 22. ? @ 0x00007fbc6213eac3 23. ? @ 0x00007fbc621d0850 (version 25.3.6.10636.altinitytest (altinity build)) 2025.07.28 11:58:11.254273 [ 17371 ] {7d445460-0628-47fe-a1e9-ae0538d6e6cc} executeQuery: Code: 497. DB::Exception: user_02916_dictionary_access_test_3: Not enough privileges. To execute this query, it's necessary to have the grant dictGet ON test_3.dict_02916_dictionary_access_test_3. (ACCESS_DENIED) (version 25.3.6.10636.altinitytest (altinity build)) (from [::1]:38392) (comment: 02916_dictionary_access.sh) (query 1, line 2) (in query: SELECT * FROM dictionary(dict_02916_dictionary_access_test_3);), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000a06a8eb 4. /build/src/Access/ContextAccess.cpp:613: 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 @ 0x0000000013788c04 5. /build/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 @ 0x00000000137876c3 6. /build/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 @ 0x0000000013786d11 7. /build/src/Access/ContextAccess.cpp:781: DB::ContextAccess::checkAccess(std::shared_ptr const&, DB::AccessFlags const&, std::basic_string_view>, std::basic_string_view>) const @ 0x00000000137594c4 8. /build/src/Access/ContextAccess.h:256: DB::Context::checkAccess(DB::AccessFlags const&, std::basic_string_view>, std::basic_string_view>) const @ 0x000000001442d454 9. /build/src/Storages/StorageDictionary.cpp:199: DB::StorageDictionary::read(std::vector> const&, std::shared_ptr const&, DB::SelectQueryInfo&, std::shared_ptr, DB::QueryProcessingStage::Enum, unsigned long, unsigned long) @ 0x0000000015d58a94 10. /build/src/Storages/IStorage.cpp:184: DB::IStorage::read(DB::QueryPlan&, std::vector> const&, std::shared_ptr const&, DB::SelectQueryInfo&, std::shared_ptr, DB::QueryProcessingStage::Enum, unsigned long, unsigned long) @ 0x0000000015d1edae 11. /build/src/Planner/PlannerJoinTree.cpp:946: DB::(anonymous namespace)::buildQueryPlanForTableExpression(std::shared_ptr, std::shared_ptr const&, DB::SelectQueryInfo const&, DB::SelectQueryOptions const&, std::shared_ptr&, bool, bool) @ 0x00000000149970ee 12. /build/src/Planner/PlannerJoinTree.cpp:2252: DB::buildJoinTreeQueryPlan(std::shared_ptr const&, DB::SelectQueryInfo const&, DB::SelectQueryOptions&, std::unordered_set, std::equal_to, std::allocator> const&, std::shared_ptr&) @ 0x000000001498e109 13. /build/src/Planner/Planner.cpp:1553: DB::Planner::buildPlanForQueryNode() @ 0x0000000014979dae 14. /build/src/Planner/Planner.cpp:1308: DB::Planner::buildQueryPlanIfNeeded() @ 0x000000001497685c 15. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:255: DB::InterpreterSelectQueryAnalyzer::getQueryPlan() @ 0x000000001497476d 16. /build/src/Interpreters/executeQuery.cpp:1405: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88806 17. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 18. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 19. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 20. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 21. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 22. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 23. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 24. ? @ 0x00007fbc6213eac3 25. ? @ 0x00007fbc621d0850 2025.07.28 11:58:11.321154 [ 17371 ] {} TCPHandler: Code: 497. DB::Exception: user_02916_dictionary_access_test_3: Not enough privileges. To execute this query, it's necessary to have the grant dictGet ON test_3.dict_02916_dictionary_access_test_3. (ACCESS_DENIED), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000a06a8eb 4. /build/src/Access/ContextAccess.cpp:613: 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 @ 0x0000000013788c04 5. /build/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 @ 0x00000000137876c3 6. /build/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 @ 0x0000000013786d11 7. /build/src/Access/ContextAccess.cpp:781: DB::ContextAccess::checkAccess(std::shared_ptr const&, DB::AccessFlags const&, std::basic_string_view>, std::basic_string_view>) const @ 0x00000000137594c4 8. /build/src/Access/ContextAccess.h:256: DB::Context::checkAccess(DB::AccessFlags const&, std::basic_string_view>, std::basic_string_view>) const @ 0x000000001442d454 9. /build/src/Storages/StorageDictionary.cpp:199: DB::StorageDictionary::read(std::vector> const&, std::shared_ptr const&, DB::SelectQueryInfo&, std::shared_ptr, DB::QueryProcessingStage::Enum, unsigned long, unsigned long) @ 0x0000000015d58a94 10. /build/src/Storages/IStorage.cpp:184: DB::IStorage::read(DB::QueryPlan&, std::vector> const&, std::shared_ptr const&, DB::SelectQueryInfo&, std::shared_ptr, DB::QueryProcessingStage::Enum, unsigned long, unsigned long) @ 0x0000000015d1edae 11. /build/src/Planner/PlannerJoinTree.cpp:946: DB::(anonymous namespace)::buildQueryPlanForTableExpression(std::shared_ptr, std::shared_ptr const&, DB::SelectQueryInfo const&, DB::SelectQueryOptions const&, std::shared_ptr&, bool, bool) @ 0x00000000149970ee 12. /build/src/Planner/PlannerJoinTree.cpp:2252: DB::buildJoinTreeQueryPlan(std::shared_ptr const&, DB::SelectQueryInfo const&, DB::SelectQueryOptions&, std::unordered_set, std::equal_to, std::allocator> const&, std::shared_ptr&) @ 0x000000001498e109 13. /build/src/Planner/Planner.cpp:1553: DB::Planner::buildPlanForQueryNode() @ 0x0000000014979dae 14. /build/src/Planner/Planner.cpp:1308: DB::Planner::buildQueryPlanIfNeeded() @ 0x000000001497685c 15. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:255: DB::InterpreterSelectQueryAnalyzer::getQueryPlan() @ 0x000000001497476d 16. /build/src/Interpreters/executeQuery.cpp:1405: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88806 17. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 18. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 19. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 20. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 21. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 22. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 23. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 24. ? @ 0x00007fbc6213eac3 25. ? @ 0x00007fbc621d0850 2025.07.28 11:58:11.612431 [ 3960 ] {} test_13.rmt2 (7f9b740d-015c-470e-8cc6-8ba33be0dc63): auto DB::StorageReplicatedMergeTree::processQueueEntry(ReplicatedMergeTreeQueue::SelectedEntryPtr)::(anonymous class)::operator()(LogEntryPtr &) const: Code: 86. DB::HTTPException: Received error from remote server http://146b4357c08d:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Ftest%2F01165%2Ftest_13%2Frmt%2Freplicas%2F1&part=20250728_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.6.10636.altinitytest (altinity build)) '. (RECEIVED_ERROR_FROM_REMOTE_IO_SERVER), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.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 const&, int&&, String const&, unsigned long&&, String const&) @ 0x000000000feda8d9 4. /build/src/IO/HTTPCommon.cpp:104: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x000000000feda6e2 5. /build/src/IO/HTTPCommon.cpp:93: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x000000000feda537 6. /build/src/IO/ReadWriteBufferFromHTTP.cpp:277: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x000000001184a4c4 7. /build/src/IO/ReadWriteBufferFromHTTP.cpp:285: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x000000001184a615 8. /build/src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x000000001184ae59 9. /build/src/IO/ReadWriteBufferFromHTTP.cpp:472: void std::__function::__policy_invoker::__call_impl[abi:se190107]>(std::__function::__policy_storage const*) @ 0x000000001184cedd 10. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001184858b 11. /build/src/IO/ReadWriteBufferFromHTTP.cpp:465: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x000000001184bf0b 12. /build/src/IO/ReadBuffer.h:60: DB::ReadBuffer::next() @ 0x000000000a148c7b 13. /build/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) @ 0x0000000011849fb2 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]>&)>&, 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&) @ 0x0000000011841980 15. /build/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) @ 0x000000001621208e 16. /build/src/Storages/StorageReplicatedMergeTree.cpp:5228: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl[abi:se190107] const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000015f9a5fe 17. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000015ed8bfd 18. /build/src/Storages/StorageReplicatedMergeTree.cpp:2514: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x0000000015ec9aab 19. /build/src/Storages/StorageReplicatedMergeTree.cpp:2349: DB::StorageReplicatedMergeTree::executeLogEntry(DB::ReplicatedMergeTreeLogEntry&) @ 0x0000000015eba91b 20. /build/src/Storages/StorageReplicatedMergeTree.cpp:3876: bool std::__function::__policy_invoker&)>::__call_impl[abi:se190107])::$_1, bool (std::shared_ptr&)>>(std::__function::__policy_storage const*, std::shared_ptr&) @ 0x0000000015f9837e 21. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000165d6fc3 22. /build/src/Storages/StorageReplicatedMergeTree.cpp:3872: DB::StorageReplicatedMergeTree::processQueueEntry(std::shared_ptr) @ 0x0000000015efc18a 23. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001624c1b2 24. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000162f9c70 25. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x00000000162fa55a 26. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc6653 27. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000000fccc4c3 28. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc3d92 29. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fcca080 30. ? @ 0x00007fbc6213eac3 31. ? @ 0x00007fbc621d0850 (version 25.3.6.10636.altinitytest (altinity build)) 2025.07.28 11:58:11.679461 [ 17321 ] {b0de388e-75fa-4d0c-9aed-89c98620faaa} executeQuery: Code: 42. DB::Exception: Map combinator takes only one map argument. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.6.10636.altinitytest (altinity build)) (from [::1]:38276) (comment: 01852_map_combinator.sql) (query 27, line 36) (in query: select sumMap(map(1,2), 1, 2);), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x000000000a06b56b 4. /build/src/AggregateFunctions/Combinators/AggregateFunctionMap.cpp:354: DB::(anonymous namespace)::AggregateFunctionCombinatorMap::transformArguments(std::vector, std::allocator>> const&) const @ 0x000000001179de0a 5. /build/src/AggregateFunctions/AggregateFunctionFactory.cpp:250: DB::AggregateFunctionFactory::getImpl(String const&, DB::NullsAction, std::vector, std::allocator>> const&, DB::Array const&, DB::AggregateFunctionProperties&, bool) const @ 0x00000000131dfff8 6. /build/src/AggregateFunctions/AggregateFunctionFactory.cpp:130: DB::AggregateFunctionFactory::get(String const&, DB::NullsAction, std::vector, std::allocator>> const&, DB::Array const&, DB::AggregateFunctionProperties&) const @ 0x00000000131df0ca 7. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3368: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000014032fed 8. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3838: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000014019a9e 9. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3980: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000014018e31 10. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:4304: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000014042fa7 11. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5605: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000014013749 12. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000140127f9 13. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000014011fce 14. /build/src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000001406ce8a 15. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000014973b42 16. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000001497268d 17. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000014974d24 18. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001492924b 19. /build/src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88641 20. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 21. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 22. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 23. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 24. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 25. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 26. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 27. ? @ 0x00007fbc6213eac3 28. ? @ 0x00007fbc621d0850 2025.07.28 11:58:11.695838 [ 17321 ] {} TCPHandler: Code: 42. DB::Exception: Map combinator takes only one map argument. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x000000000a06b56b 4. /build/src/AggregateFunctions/Combinators/AggregateFunctionMap.cpp:354: DB::(anonymous namespace)::AggregateFunctionCombinatorMap::transformArguments(std::vector, std::allocator>> const&) const @ 0x000000001179de0a 5. /build/src/AggregateFunctions/AggregateFunctionFactory.cpp:250: DB::AggregateFunctionFactory::getImpl(String const&, DB::NullsAction, std::vector, std::allocator>> const&, DB::Array const&, DB::AggregateFunctionProperties&, bool) const @ 0x00000000131dfff8 6. /build/src/AggregateFunctions/AggregateFunctionFactory.cpp:130: DB::AggregateFunctionFactory::get(String const&, DB::NullsAction, std::vector, std::allocator>> const&, DB::Array const&, DB::AggregateFunctionProperties&) const @ 0x00000000131df0ca 7. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3368: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000014032fed 8. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3838: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000014019a9e 9. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3980: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000014018e31 10. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:4304: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000014042fa7 11. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5605: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000014013749 12. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000140127f9 13. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000014011fce 14. /build/src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000001406ce8a 15. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000014973b42 16. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000001497268d 17. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000014974d24 18. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001492924b 19. /build/src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88641 20. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 21. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 22. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 23. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 24. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 25. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 26. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 27. ? @ 0x00007fbc6213eac3 28. ? @ 0x00007fbc621d0850 2025.07.28 11:58:11.703829 [ 17208 ] {3682c7ff-a80e-4380-b1a2-be4320666830} executeQuery: Code: 497. DB::Exception: user_02916_dictionary_access_test_3: Not enough privileges. To execute this query, it's necessary to have the grant dictGet ON test_3.dict_02916_dictionary_access_test_3: In scope SELECT dictGet(dict_02916_dictionary_access_test_3, 'value', 1). (ACCESS_DENIED) (version 25.3.6.10636.altinitytest (altinity build)) (from [::1]:59596) (comment: 02916_dictionary_access.sh) (query 1, line 2) (in query: SELECT dictGet(dict_02916_dictionary_access_test_3, 'value', 1);), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000a06a8eb 4. /build/src/Access/ContextAccess.cpp:613: 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 @ 0x0000000013788c04 5. /build/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 @ 0x00000000137876c3 6. /build/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 @ 0x0000000013786d11 7. /build/src/Access/ContextAccess.cpp:781: DB::ContextAccess::checkAccess(std::shared_ptr const&, DB::AccessFlags const&, std::basic_string_view>, std::basic_string_view>) const @ 0x00000000137594c4 8. /build/src/Access/ContextAccess.h:256: DB::Context::checkAccess(DB::AccessFlags const&, std::basic_string_view>, std::basic_string_view>) const @ 0x000000001442d454 9. /build/src/Functions/FunctionsExternalDictionaries.h:80: DB::FunctionDictHelper::getDictionary(String const&) @ 0x000000000a1d05b4 10. /build/src/Functions/FunctionsExternalDictionaries.h:426: DB::FunctionDictGetNoType<(DB::DictionaryGetFunctionType)0>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000a1cd55e 11. /build/src/Functions/IFunction.h:437: DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000a069f2a 12. /build/src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000012d9965a 13. /build/src/Functions/IFunction.cpp:351: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d93b02 14. /build/src/Functions/IFunction.cpp:177: DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d93698 15. /build/src/Functions/IFunction.cpp:343: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d93aad 16. /build/src/Functions/IFunction.cpp:420: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d95059 17. /build/src/Functions/IFunction.cpp:498: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d95c72 18. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3567: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000014034494 19. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3838: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000014019a9e 20. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3980: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000014018e31 21. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:4304: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000014042fa7 22. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5605: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000014013749 23. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000140127f9 24. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000014011fce 25. /build/src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000001406ce8a 26. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000014973b42 27. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000001497268d 28. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000014974d24 29. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001492924b 30. /build/src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88641 31. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 2025.07.28 11:58:11.738307 [ 17208 ] {} TCPHandler: Code: 497. DB::Exception: user_02916_dictionary_access_test_3: Not enough privileges. To execute this query, it's necessary to have the grant dictGet ON test_3.dict_02916_dictionary_access_test_3: In scope SELECT dictGet(dict_02916_dictionary_access_test_3, 'value', 1). (ACCESS_DENIED), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000a06a8eb 4. /build/src/Access/ContextAccess.cpp:613: 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 @ 0x0000000013788c04 5. /build/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 @ 0x00000000137876c3 6. /build/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 @ 0x0000000013786d11 7. /build/src/Access/ContextAccess.cpp:781: DB::ContextAccess::checkAccess(std::shared_ptr const&, DB::AccessFlags const&, std::basic_string_view>, std::basic_string_view>) const @ 0x00000000137594c4 8. /build/src/Access/ContextAccess.h:256: DB::Context::checkAccess(DB::AccessFlags const&, std::basic_string_view>, std::basic_string_view>) const @ 0x000000001442d454 9. /build/src/Functions/FunctionsExternalDictionaries.h:80: DB::FunctionDictHelper::getDictionary(String const&) @ 0x000000000a1d05b4 10. /build/src/Functions/FunctionsExternalDictionaries.h:426: DB::FunctionDictGetNoType<(DB::DictionaryGetFunctionType)0>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000a1cd55e 11. /build/src/Functions/IFunction.h:437: DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000a069f2a 12. /build/src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000012d9965a 13. /build/src/Functions/IFunction.cpp:351: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d93b02 14. /build/src/Functions/IFunction.cpp:177: DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d93698 15. /build/src/Functions/IFunction.cpp:343: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d93aad 16. /build/src/Functions/IFunction.cpp:420: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d95059 17. /build/src/Functions/IFunction.cpp:498: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d95c72 18. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3567: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000014034494 19. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3838: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000014019a9e 20. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3980: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000014018e31 21. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:4304: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000014042fa7 22. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5605: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000014013749 23. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000140127f9 24. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000014011fce 25. /build/src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000001406ce8a 26. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000014973b42 27. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000001497268d 28. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000014974d24 29. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001492924b 30. /build/src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88641 31. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 2025.07.28 11:58:11.771660 [ 17321 ] {97d573ce-6191-4cb0-b877-969b4a0ec2da} executeQuery: Code: 42. DB::Exception: Map combinator takes only one map argument. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.6.10636.altinitytest (altinity build)) (from [::1]:38276) (comment: 01852_map_combinator.sql) (query 28, line 37) (in query: select sumMap(map(1,2), map(1,3));), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x000000000a06b56b 4. /build/src/AggregateFunctions/Combinators/AggregateFunctionMap.cpp:354: DB::(anonymous namespace)::AggregateFunctionCombinatorMap::transformArguments(std::vector, std::allocator>> const&) const @ 0x000000001179de0a 5. /build/src/AggregateFunctions/AggregateFunctionFactory.cpp:250: DB::AggregateFunctionFactory::getImpl(String const&, DB::NullsAction, std::vector, std::allocator>> const&, DB::Array const&, DB::AggregateFunctionProperties&, bool) const @ 0x00000000131dfff8 6. /build/src/AggregateFunctions/AggregateFunctionFactory.cpp:130: DB::AggregateFunctionFactory::get(String const&, DB::NullsAction, std::vector, std::allocator>> const&, DB::Array const&, DB::AggregateFunctionProperties&) const @ 0x00000000131df0ca 7. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3368: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000014032fed 8. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3838: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000014019a9e 9. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3980: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000014018e31 10. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:4304: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000014042fa7 11. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5605: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000014013749 12. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000140127f9 13. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000014011fce 14. /build/src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000001406ce8a 15. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000014973b42 16. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000001497268d 17. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000014974d24 18. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001492924b 19. /build/src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88641 20. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 21. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 22. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 23. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 24. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 25. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 26. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 27. ? @ 0x00007fbc6213eac3 28. ? @ 0x00007fbc621d0850 2025.07.28 11:58:11.797493 [ 17321 ] {} TCPHandler: Code: 42. DB::Exception: Map combinator takes only one map argument. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x000000000a06b56b 4. /build/src/AggregateFunctions/Combinators/AggregateFunctionMap.cpp:354: DB::(anonymous namespace)::AggregateFunctionCombinatorMap::transformArguments(std::vector, std::allocator>> const&) const @ 0x000000001179de0a 5. /build/src/AggregateFunctions/AggregateFunctionFactory.cpp:250: DB::AggregateFunctionFactory::getImpl(String const&, DB::NullsAction, std::vector, std::allocator>> const&, DB::Array const&, DB::AggregateFunctionProperties&, bool) const @ 0x00000000131dfff8 6. /build/src/AggregateFunctions/AggregateFunctionFactory.cpp:130: DB::AggregateFunctionFactory::get(String const&, DB::NullsAction, std::vector, std::allocator>> const&, DB::Array const&, DB::AggregateFunctionProperties&) const @ 0x00000000131df0ca 7. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3368: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000014032fed 8. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3838: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000014019a9e 9. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3980: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000014018e31 10. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:4304: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000014042fa7 11. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5605: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000014013749 12. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000140127f9 13. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000014011fce 14. /build/src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000001406ce8a 15. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000014973b42 16. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000001497268d 17. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000014974d24 18. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001492924b 19. /build/src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88641 20. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 21. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 22. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 23. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 24. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 25. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 26. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 27. ? @ 0x00007fbc6213eac3 28. ? @ 0x00007fbc621d0850 2025.07.28 11:58:12.119720 [ 17321 ] {34e66214-cf71-439d-8ef8-90c41029612a} executeQuery: Code: 43. DB::Exception: Aggregation 'avgMap' is not implemented for mapped arrays. (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.6.10636.altinitytest (altinity build)) (from [::1]:38276) (comment: 01852_map_combinator.sql) (query 29, line 39) (in query: -- array and tuple arguments select avgMap([1,1,1], [2,2,2]);), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x000000000a080b2b 4. /build/src/AggregateFunctions/Combinators/AggregateFunctionMap.cpp:453: DB::(anonymous namespace)::AggregateFunctionCombinatorMap::transformAggregateFunction(std::shared_ptr const&, DB::AggregateFunctionProperties const&, std::vector, std::allocator>> const&, DB::Array const&) const @ 0x00000000117a1666 5. /build/src/AggregateFunctions/AggregateFunctionFactory.cpp:260: DB::AggregateFunctionFactory::getImpl(String const&, DB::NullsAction, std::vector, std::allocator>> const&, DB::Array const&, DB::AggregateFunctionProperties&, bool) const @ 0x00000000131e02f6 6. /build/src/AggregateFunctions/AggregateFunctionFactory.cpp:130: DB::AggregateFunctionFactory::get(String const&, DB::NullsAction, std::vector, std::allocator>> const&, DB::Array const&, DB::AggregateFunctionProperties&) const @ 0x00000000131df0ca 7. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3368: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000014032fed 8. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3838: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000014019a9e 9. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3980: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000014018e31 10. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:4304: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000014042fa7 11. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5605: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000014013749 12. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000140127f9 13. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000014011fce 14. /build/src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000001406ce8a 15. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000014973b42 16. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000001497268d 17. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000014974d24 18. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001492924b 19. /build/src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88641 20. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 21. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 22. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 23. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 24. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 25. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 26. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 27. ? @ 0x00007fbc6213eac3 28. ? @ 0x00007fbc621d0850 2025.07.28 11:58:12.129328 [ 17321 ] {} TCPHandler: Code: 43. DB::Exception: Aggregation 'avgMap' is not implemented for mapped arrays. (ILLEGAL_TYPE_OF_ARGUMENT), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x000000000a080b2b 4. /build/src/AggregateFunctions/Combinators/AggregateFunctionMap.cpp:453: DB::(anonymous namespace)::AggregateFunctionCombinatorMap::transformAggregateFunction(std::shared_ptr const&, DB::AggregateFunctionProperties const&, std::vector, std::allocator>> const&, DB::Array const&) const @ 0x00000000117a1666 5. /build/src/AggregateFunctions/AggregateFunctionFactory.cpp:260: DB::AggregateFunctionFactory::getImpl(String const&, DB::NullsAction, std::vector, std::allocator>> const&, DB::Array const&, DB::AggregateFunctionProperties&, bool) const @ 0x00000000131e02f6 6. /build/src/AggregateFunctions/AggregateFunctionFactory.cpp:130: DB::AggregateFunctionFactory::get(String const&, DB::NullsAction, std::vector, std::allocator>> const&, DB::Array const&, DB::AggregateFunctionProperties&) const @ 0x00000000131df0ca 7. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3368: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000014032fed 8. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3838: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000014019a9e 9. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3980: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000014018e31 10. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:4304: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000014042fa7 11. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5605: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000014013749 12. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000140127f9 13. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000014011fce 14. /build/src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000001406ce8a 15. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000014973b42 16. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000001497268d 17. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000014974d24 18. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001492924b 19. /build/src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88641 20. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 21. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 22. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 23. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 24. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 25. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 26. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 27. ? @ 0x00007fbc6213eac3 28. ? @ 0x00007fbc621d0850 2025.07.28 11:58:12.306834 [ 17321 ] {fe10256e-2b0d-4b00-8e7e-8261a71d662d} executeQuery: Code: 43. DB::Exception: Aggregate function Map requires map as argument. (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.6.10636.altinitytest (altinity build)) (from [::1]:38276) (comment: 01852_map_combinator.sql) (query 30, line 41) (in query: select minMap((1,1));), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x000000000a06b56b 4. /build/src/AggregateFunctions/Combinators/AggregateFunctionMap.cpp:383: DB::(anonymous namespace)::AggregateFunctionCombinatorMap::transformArguments(std::vector, std::allocator>> const&) const @ 0x000000001179dd6e 5. /build/src/AggregateFunctions/AggregateFunctionFactory.cpp:250: DB::AggregateFunctionFactory::getImpl(String const&, DB::NullsAction, std::vector, std::allocator>> const&, DB::Array const&, DB::AggregateFunctionProperties&, bool) const @ 0x00000000131dfff8 6. /build/src/AggregateFunctions/AggregateFunctionFactory.cpp:130: DB::AggregateFunctionFactory::get(String const&, DB::NullsAction, std::vector, std::allocator>> const&, DB::Array const&, DB::AggregateFunctionProperties&) const @ 0x00000000131df0ca 7. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3368: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000014032fed 8. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3838: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000014019a9e 9. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3980: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000014018e31 10. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:4304: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000014042fa7 11. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5605: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000014013749 12. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000140127f9 13. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000014011fce 14. /build/src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000001406ce8a 15. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000014973b42 16. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000001497268d 17. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000014974d24 18. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001492924b 19. /build/src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88641 20. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 21. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 22. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 23. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 24. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 25. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 26. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 27. ? @ 0x00007fbc6213eac3 28. ? @ 0x00007fbc621d0850 2025.07.28 11:58:12.323440 [ 17321 ] {} TCPHandler: Code: 43. DB::Exception: Aggregate function Map requires map as argument. (ILLEGAL_TYPE_OF_ARGUMENT), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x000000000a06b56b 4. /build/src/AggregateFunctions/Combinators/AggregateFunctionMap.cpp:383: DB::(anonymous namespace)::AggregateFunctionCombinatorMap::transformArguments(std::vector, std::allocator>> const&) const @ 0x000000001179dd6e 5. /build/src/AggregateFunctions/AggregateFunctionFactory.cpp:250: DB::AggregateFunctionFactory::getImpl(String const&, DB::NullsAction, std::vector, std::allocator>> const&, DB::Array const&, DB::AggregateFunctionProperties&, bool) const @ 0x00000000131dfff8 6. /build/src/AggregateFunctions/AggregateFunctionFactory.cpp:130: DB::AggregateFunctionFactory::get(String const&, DB::NullsAction, std::vector, std::allocator>> const&, DB::Array const&, DB::AggregateFunctionProperties&) const @ 0x00000000131df0ca 7. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3368: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000014032fed 8. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3838: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000014019a9e 9. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3980: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000014018e31 10. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:4304: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000014042fa7 11. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5605: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000014013749 12. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000140127f9 13. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000014011fce 14. /build/src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000001406ce8a 15. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000014973b42 16. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000001497268d 17. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000014974d24 18. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001492924b 19. /build/src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88641 20. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 21. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 22. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 23. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 24. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 25. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 26. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 27. ? @ 0x00007fbc6213eac3 28. ? @ 0x00007fbc621d0850 2025.07.28 11:58:12.423500 [ 3972 ] {} test_13.rmt2 (7f9b740d-015c-470e-8cc6-8ba33be0dc63): auto DB::StorageReplicatedMergeTree::processQueueEntry(ReplicatedMergeTreeQueue::SelectedEntryPtr)::(anonymous class)::operator()(LogEntryPtr &) const: Code: 86. DB::HTTPException: Received error from remote server http://146b4357c08d:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Ftest%2F01165%2Ftest_13%2Frmt%2Freplicas%2F1&part=20250728_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.6.10636.altinitytest (altinity build)) '. (RECEIVED_ERROR_FROM_REMOTE_IO_SERVER), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.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 const&, int&&, String const&, unsigned long&&, String const&) @ 0x000000000feda8d9 4. /build/src/IO/HTTPCommon.cpp:104: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x000000000feda6e2 5. /build/src/IO/HTTPCommon.cpp:93: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x000000000feda537 6. /build/src/IO/ReadWriteBufferFromHTTP.cpp:277: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x000000001184a4c4 7. /build/src/IO/ReadWriteBufferFromHTTP.cpp:285: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x000000001184a615 8. /build/src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x000000001184ae59 9. /build/src/IO/ReadWriteBufferFromHTTP.cpp:472: void std::__function::__policy_invoker::__call_impl[abi:se190107]>(std::__function::__policy_storage const*) @ 0x000000001184cedd 10. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001184858b 11. /build/src/IO/ReadWriteBufferFromHTTP.cpp:465: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x000000001184bf0b 12. /build/src/IO/ReadBuffer.h:60: DB::ReadBuffer::next() @ 0x000000000a148c7b 13. /build/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) @ 0x0000000011849fb2 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]>&)>&, 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&) @ 0x0000000011841980 15. /build/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) @ 0x000000001621208e 16. /build/src/Storages/StorageReplicatedMergeTree.cpp:5228: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl[abi:se190107] const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000015f9a5fe 17. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000015ed8bfd 18. /build/src/Storages/StorageReplicatedMergeTree.cpp:2514: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x0000000015ec9aab 19. /build/src/Storages/StorageReplicatedMergeTree.cpp:2349: DB::StorageReplicatedMergeTree::executeLogEntry(DB::ReplicatedMergeTreeLogEntry&) @ 0x0000000015eba91b 20. /build/src/Storages/StorageReplicatedMergeTree.cpp:3876: bool std::__function::__policy_invoker&)>::__call_impl[abi:se190107])::$_1, bool (std::shared_ptr&)>>(std::__function::__policy_storage const*, std::shared_ptr&) @ 0x0000000015f9837e 21. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000165d6fc3 22. /build/src/Storages/StorageReplicatedMergeTree.cpp:3872: DB::StorageReplicatedMergeTree::processQueueEntry(std::shared_ptr) @ 0x0000000015efc18a 23. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001624c1b2 24. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000162f9c70 25. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x00000000162fa55a 26. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc6653 27. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000000fccc4c3 28. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc3d92 29. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fcca080 30. ? @ 0x00007fbc6213eac3 31. ? @ 0x00007fbc621d0850 (version 25.3.6.10636.altinitytest (altinity build)) 2025.07.28 11:58:12.520152 [ 17321 ] {5799b16c-3dc3-4453-bb59-4270550f52b1} executeQuery: Code: 43. DB::Exception: Aggregate function Map requires map as argument. (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.6.10636.altinitytest (altinity build)) (from [::1]:38276) (comment: 01852_map_combinator.sql) (query 31, line 42) (in query: select minMap(([1,1,1],1));), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x000000000a06b56b 4. /build/src/AggregateFunctions/Combinators/AggregateFunctionMap.cpp:383: DB::(anonymous namespace)::AggregateFunctionCombinatorMap::transformArguments(std::vector, std::allocator>> const&) const @ 0x000000001179dd6e 5. /build/src/AggregateFunctions/AggregateFunctionFactory.cpp:250: DB::AggregateFunctionFactory::getImpl(String const&, DB::NullsAction, std::vector, std::allocator>> const&, DB::Array const&, DB::AggregateFunctionProperties&, bool) const @ 0x00000000131dfff8 6. /build/src/AggregateFunctions/AggregateFunctionFactory.cpp:130: DB::AggregateFunctionFactory::get(String const&, DB::NullsAction, std::vector, std::allocator>> const&, DB::Array const&, DB::AggregateFunctionProperties&) const @ 0x00000000131df0ca 7. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3368: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000014032fed 8. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3838: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000014019a9e 9. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3980: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000014018e31 10. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:4304: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000014042fa7 11. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5605: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000014013749 12. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000140127f9 13. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000014011fce 14. /build/src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000001406ce8a 15. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000014973b42 16. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000001497268d 17. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000014974d24 18. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001492924b 19. /build/src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88641 20. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 21. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 22. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 23. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 24. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 25. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 26. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 27. ? @ 0x00007fbc6213eac3 28. ? @ 0x00007fbc621d0850 2025.07.28 11:58:12.558456 [ 17321 ] {} TCPHandler: Code: 43. DB::Exception: Aggregate function Map requires map as argument. (ILLEGAL_TYPE_OF_ARGUMENT), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x000000000a06b56b 4. /build/src/AggregateFunctions/Combinators/AggregateFunctionMap.cpp:383: DB::(anonymous namespace)::AggregateFunctionCombinatorMap::transformArguments(std::vector, std::allocator>> const&) const @ 0x000000001179dd6e 5. /build/src/AggregateFunctions/AggregateFunctionFactory.cpp:250: DB::AggregateFunctionFactory::getImpl(String const&, DB::NullsAction, std::vector, std::allocator>> const&, DB::Array const&, DB::AggregateFunctionProperties&, bool) const @ 0x00000000131dfff8 6. /build/src/AggregateFunctions/AggregateFunctionFactory.cpp:130: DB::AggregateFunctionFactory::get(String const&, DB::NullsAction, std::vector, std::allocator>> const&, DB::Array const&, DB::AggregateFunctionProperties&) const @ 0x00000000131df0ca 7. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3368: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000014032fed 8. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3838: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000014019a9e 9. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3980: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000014018e31 10. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:4304: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000014042fa7 11. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5605: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000014013749 12. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000140127f9 13. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000014011fce 14. /build/src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000001406ce8a 15. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000014973b42 16. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000001497268d 17. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000014974d24 18. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001492924b 19. /build/src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88641 20. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 21. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 22. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 23. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 24. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 25. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 26. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 27. ? @ 0x00007fbc6213eac3 28. ? @ 0x00007fbc621d0850 2025.07.28 11:58:12.730796 [ 17321 ] {79e65d49-341a-42f6-b1e8-068afe1740e6} executeQuery: Code: 43. DB::Exception: Aggregate function Map requires map as argument. (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.6.10636.altinitytest (altinity build)) (from [::1]:38276) (comment: 01852_map_combinator.sql) (query 32, line 43) (in query: select minMap([1,1,1],1);), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x000000000a06b56b 4. /build/src/AggregateFunctions/Combinators/AggregateFunctionMap.cpp:383: DB::(anonymous namespace)::AggregateFunctionCombinatorMap::transformArguments(std::vector, std::allocator>> const&) const @ 0x000000001179dd6e 5. /build/src/AggregateFunctions/AggregateFunctionFactory.cpp:250: DB::AggregateFunctionFactory::getImpl(String const&, DB::NullsAction, std::vector, std::allocator>> const&, DB::Array const&, DB::AggregateFunctionProperties&, bool) const @ 0x00000000131dfff8 6. /build/src/AggregateFunctions/AggregateFunctionFactory.cpp:130: DB::AggregateFunctionFactory::get(String const&, DB::NullsAction, std::vector, std::allocator>> const&, DB::Array const&, DB::AggregateFunctionProperties&) const @ 0x00000000131df0ca 7. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3368: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000014032fed 8. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3838: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000014019a9e 9. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3980: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000014018e31 10. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:4304: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000014042fa7 11. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5605: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000014013749 12. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000140127f9 13. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000014011fce 14. /build/src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000001406ce8a 15. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000014973b42 16. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000001497268d 17. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000014974d24 18. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001492924b 19. /build/src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88641 20. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 21. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 22. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 23. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 24. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 25. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 26. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 27. ? @ 0x00007fbc6213eac3 28. ? @ 0x00007fbc621d0850 2025.07.28 11:58:12.742739 [ 17321 ] {} TCPHandler: Code: 43. DB::Exception: Aggregate function Map requires map as argument. (ILLEGAL_TYPE_OF_ARGUMENT), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x000000000a06b56b 4. /build/src/AggregateFunctions/Combinators/AggregateFunctionMap.cpp:383: DB::(anonymous namespace)::AggregateFunctionCombinatorMap::transformArguments(std::vector, std::allocator>> const&) const @ 0x000000001179dd6e 5. /build/src/AggregateFunctions/AggregateFunctionFactory.cpp:250: DB::AggregateFunctionFactory::getImpl(String const&, DB::NullsAction, std::vector, std::allocator>> const&, DB::Array const&, DB::AggregateFunctionProperties&, bool) const @ 0x00000000131dfff8 6. /build/src/AggregateFunctions/AggregateFunctionFactory.cpp:130: DB::AggregateFunctionFactory::get(String const&, DB::NullsAction, std::vector, std::allocator>> const&, DB::Array const&, DB::AggregateFunctionProperties&) const @ 0x00000000131df0ca 7. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3368: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000014032fed 8. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3838: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000014019a9e 9. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3980: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000014018e31 10. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:4304: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000014042fa7 11. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5605: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000014013749 12. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000140127f9 13. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000014011fce 14. /build/src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000001406ce8a 15. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000014973b42 16. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000001497268d 17. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000014974d24 18. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001492924b 19. /build/src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88641 20. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 21. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 22. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 23. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 24. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 25. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 26. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 27. ? @ 0x00007fbc6213eac3 28. ? @ 0x00007fbc621d0850 2025.07.28 11:58:12.851073 [ 17321 ] {42d6efd3-9dda-45a9-ab14-327df718f5b2} executeQuery: Code: 43. DB::Exception: Aggregate function Map requires map as argument. (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.6.10636.altinitytest (altinity build)) (from [::1]:38276) (comment: 01852_map_combinator.sql) (query 33, line 44) (in query: select minMap([1,1,1]);), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x000000000a06b56b 4. /build/src/AggregateFunctions/Combinators/AggregateFunctionMap.cpp:383: DB::(anonymous namespace)::AggregateFunctionCombinatorMap::transformArguments(std::vector, std::allocator>> const&) const @ 0x000000001179dd6e 5. /build/src/AggregateFunctions/AggregateFunctionFactory.cpp:250: DB::AggregateFunctionFactory::getImpl(String const&, DB::NullsAction, std::vector, std::allocator>> const&, DB::Array const&, DB::AggregateFunctionProperties&, bool) const @ 0x00000000131dfff8 6. /build/src/AggregateFunctions/AggregateFunctionFactory.cpp:130: DB::AggregateFunctionFactory::get(String const&, DB::NullsAction, std::vector, std::allocator>> const&, DB::Array const&, DB::AggregateFunctionProperties&) const @ 0x00000000131df0ca 7. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3368: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000014032fed 8. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3838: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000014019a9e 9. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3980: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000014018e31 10. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:4304: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000014042fa7 11. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5605: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000014013749 12. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000140127f9 13. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000014011fce 14. /build/src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000001406ce8a 15. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000014973b42 16. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000001497268d 17. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000014974d24 18. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001492924b 19. /build/src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88641 20. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 21. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 22. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 23. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 24. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 25. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 26. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 27. ? @ 0x00007fbc6213eac3 28. ? @ 0x00007fbc621d0850 2025.07.28 11:58:12.879916 [ 17321 ] {} TCPHandler: Code: 43. DB::Exception: Aggregate function Map requires map as argument. (ILLEGAL_TYPE_OF_ARGUMENT), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x000000000a06b56b 4. /build/src/AggregateFunctions/Combinators/AggregateFunctionMap.cpp:383: DB::(anonymous namespace)::AggregateFunctionCombinatorMap::transformArguments(std::vector, std::allocator>> const&) const @ 0x000000001179dd6e 5. /build/src/AggregateFunctions/AggregateFunctionFactory.cpp:250: DB::AggregateFunctionFactory::getImpl(String const&, DB::NullsAction, std::vector, std::allocator>> const&, DB::Array const&, DB::AggregateFunctionProperties&, bool) const @ 0x00000000131dfff8 6. /build/src/AggregateFunctions/AggregateFunctionFactory.cpp:130: DB::AggregateFunctionFactory::get(String const&, DB::NullsAction, std::vector, std::allocator>> const&, DB::Array const&, DB::AggregateFunctionProperties&) const @ 0x00000000131df0ca 7. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3368: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000014032fed 8. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3838: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000014019a9e 9. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3980: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000014018e31 10. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:4304: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000014042fa7 11. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5605: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000014013749 12. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000140127f9 13. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000014011fce 14. /build/src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000001406ce8a 15. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000014973b42 16. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000001497268d 17. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000014974d24 18. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001492924b 19. /build/src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88641 20. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 21. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 22. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 23. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 24. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 25. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 26. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 27. ? @ 0x00007fbc6213eac3 28. ? @ 0x00007fbc621d0850 2025.07.28 11:58:12.954530 [ 17321 ] {4a5f5b50-e696-4b25-9d27-803b78be92db} executeQuery: Code: 43. DB::Exception: Aggregate function Map requires map as argument. (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.6.10636.altinitytest (altinity build)) (from [::1]:38276) (comment: 01852_map_combinator.sql) (query 34, line 45) (in query: select minMap(([1,1,1]));), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x000000000a06b56b 4. /build/src/AggregateFunctions/Combinators/AggregateFunctionMap.cpp:383: DB::(anonymous namespace)::AggregateFunctionCombinatorMap::transformArguments(std::vector, std::allocator>> const&) const @ 0x000000001179dd6e 5. /build/src/AggregateFunctions/AggregateFunctionFactory.cpp:250: DB::AggregateFunctionFactory::getImpl(String const&, DB::NullsAction, std::vector, std::allocator>> const&, DB::Array const&, DB::AggregateFunctionProperties&, bool) const @ 0x00000000131dfff8 6. /build/src/AggregateFunctions/AggregateFunctionFactory.cpp:130: DB::AggregateFunctionFactory::get(String const&, DB::NullsAction, std::vector, std::allocator>> const&, DB::Array const&, DB::AggregateFunctionProperties&) const @ 0x00000000131df0ca 7. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3368: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000014032fed 8. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3838: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000014019a9e 9. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3980: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000014018e31 10. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:4304: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000014042fa7 11. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5605: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000014013749 12. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000140127f9 13. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000014011fce 14. /build/src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000001406ce8a 15. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000014973b42 16. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000001497268d 17. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000014974d24 18. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001492924b 19. /build/src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88641 20. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 21. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 22. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 23. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 24. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 25. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 26. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 27. ? @ 0x00007fbc6213eac3 28. ? @ 0x00007fbc621d0850 2025.07.28 11:58:12.968872 [ 17321 ] {} TCPHandler: Code: 43. DB::Exception: Aggregate function Map requires map as argument. (ILLEGAL_TYPE_OF_ARGUMENT), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x000000000a06b56b 4. /build/src/AggregateFunctions/Combinators/AggregateFunctionMap.cpp:383: DB::(anonymous namespace)::AggregateFunctionCombinatorMap::transformArguments(std::vector, std::allocator>> const&) const @ 0x000000001179dd6e 5. /build/src/AggregateFunctions/AggregateFunctionFactory.cpp:250: DB::AggregateFunctionFactory::getImpl(String const&, DB::NullsAction, std::vector, std::allocator>> const&, DB::Array const&, DB::AggregateFunctionProperties&, bool) const @ 0x00000000131dfff8 6. /build/src/AggregateFunctions/AggregateFunctionFactory.cpp:130: DB::AggregateFunctionFactory::get(String const&, DB::NullsAction, std::vector, std::allocator>> const&, DB::Array const&, DB::AggregateFunctionProperties&) const @ 0x00000000131df0ca 7. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3368: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000014032fed 8. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3838: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000014019a9e 9. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3980: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000014018e31 10. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:4304: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000014042fa7 11. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5605: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000014013749 12. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000140127f9 13. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000014011fce 14. /build/src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000001406ce8a 15. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000014973b42 16. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000001497268d 17. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000014974d24 18. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001492924b 19. /build/src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88641 20. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 21. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 22. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 23. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 24. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 25. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 26. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 27. ? @ 0x00007fbc6213eac3 28. ? @ 0x00007fbc621d0850 2025.07.28 11:58:13.529891 [ 3976 ] {} test_13.rmt2 (7f9b740d-015c-470e-8cc6-8ba33be0dc63): auto DB::StorageReplicatedMergeTree::processQueueEntry(ReplicatedMergeTreeQueue::SelectedEntryPtr)::(anonymous class)::operator()(LogEntryPtr &) const: Code: 86. DB::HTTPException: Received error from remote server http://146b4357c08d:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Ftest%2F01165%2Ftest_13%2Frmt%2Freplicas%2F1&part=20250728_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.6.10636.altinitytest (altinity build)) '. (RECEIVED_ERROR_FROM_REMOTE_IO_SERVER), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.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 const&, int&&, String const&, unsigned long&&, String const&) @ 0x000000000feda8d9 4. /build/src/IO/HTTPCommon.cpp:104: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x000000000feda6e2 5. /build/src/IO/HTTPCommon.cpp:93: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x000000000feda537 6. /build/src/IO/ReadWriteBufferFromHTTP.cpp:277: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x000000001184a4c4 7. /build/src/IO/ReadWriteBufferFromHTTP.cpp:285: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x000000001184a615 8. /build/src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x000000001184ae59 9. /build/src/IO/ReadWriteBufferFromHTTP.cpp:472: void std::__function::__policy_invoker::__call_impl[abi:se190107]>(std::__function::__policy_storage const*) @ 0x000000001184cedd 10. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001184858b 11. /build/src/IO/ReadWriteBufferFromHTTP.cpp:465: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x000000001184bf0b 12. /build/src/IO/ReadBuffer.h:60: DB::ReadBuffer::next() @ 0x000000000a148c7b 13. /build/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) @ 0x0000000011849fb2 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]>&)>&, 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&) @ 0x0000000011841980 15. /build/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) @ 0x000000001621208e 16. /build/src/Storages/StorageReplicatedMergeTree.cpp:5228: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl[abi:se190107] const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000015f9a5fe 17. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000015ed8bfd 18. /build/src/Storages/StorageReplicatedMergeTree.cpp:2514: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x0000000015ec9aab 19. /build/src/Storages/StorageReplicatedMergeTree.cpp:2349: DB::StorageReplicatedMergeTree::executeLogEntry(DB::ReplicatedMergeTreeLogEntry&) @ 0x0000000015eba91b 20. /build/src/Storages/StorageReplicatedMergeTree.cpp:3876: bool std::__function::__policy_invoker&)>::__call_impl[abi:se190107])::$_1, bool (std::shared_ptr&)>>(std::__function::__policy_storage const*, std::shared_ptr&) @ 0x0000000015f9837e 21. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000165d6fc3 22. /build/src/Storages/StorageReplicatedMergeTree.cpp:3872: DB::StorageReplicatedMergeTree::processQueueEntry(std::shared_ptr) @ 0x0000000015efc18a 23. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001624c1b2 24. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000162f9c70 25. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x00000000162fa55a 26. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc6653 27. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000000fccc4c3 28. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc3d92 29. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fcca080 30. ? @ 0x00007fbc6213eac3 31. ? @ 0x00007fbc621d0850 (version 25.3.6.10636.altinitytest (altinity build)) 2025.07.28 11:58:14.581328 [ 3967 ] {} test_13.rmt2 (7f9b740d-015c-470e-8cc6-8ba33be0dc63): auto DB::StorageReplicatedMergeTree::processQueueEntry(ReplicatedMergeTreeQueue::SelectedEntryPtr)::(anonymous class)::operator()(LogEntryPtr &) const: Code: 86. DB::HTTPException: Received error from remote server http://146b4357c08d:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Ftest%2F01165%2Ftest_13%2Frmt%2Freplicas%2F1&part=20250728_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.6.10636.altinitytest (altinity build)) '. (RECEIVED_ERROR_FROM_REMOTE_IO_SERVER), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.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 const&, int&&, String const&, unsigned long&&, String const&) @ 0x000000000feda8d9 4. /build/src/IO/HTTPCommon.cpp:104: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x000000000feda6e2 5. /build/src/IO/HTTPCommon.cpp:93: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x000000000feda537 6. /build/src/IO/ReadWriteBufferFromHTTP.cpp:277: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x000000001184a4c4 7. /build/src/IO/ReadWriteBufferFromHTTP.cpp:285: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x000000001184a615 8. /build/src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x000000001184ae59 9. /build/src/IO/ReadWriteBufferFromHTTP.cpp:472: void std::__function::__policy_invoker::__call_impl[abi:se190107]>(std::__function::__policy_storage const*) @ 0x000000001184cedd 10. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001184858b 11. /build/src/IO/ReadWriteBufferFromHTTP.cpp:465: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x000000001184bf0b 12. /build/src/IO/ReadBuffer.h:60: DB::ReadBuffer::next() @ 0x000000000a148c7b 13. /build/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) @ 0x0000000011849fb2 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]>&)>&, 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&) @ 0x0000000011841980 15. /build/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) @ 0x000000001621208e 16. /build/src/Storages/StorageReplicatedMergeTree.cpp:5228: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl[abi:se190107] const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000015f9a5fe 17. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000015ed8bfd 18. /build/src/Storages/StorageReplicatedMergeTree.cpp:2514: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x0000000015ec9aab 19. /build/src/Storages/StorageReplicatedMergeTree.cpp:2349: DB::StorageReplicatedMergeTree::executeLogEntry(DB::ReplicatedMergeTreeLogEntry&) @ 0x0000000015eba91b 20. /build/src/Storages/StorageReplicatedMergeTree.cpp:3876: bool std::__function::__policy_invoker&)>::__call_impl[abi:se190107])::$_1, bool (std::shared_ptr&)>>(std::__function::__policy_storage const*, std::shared_ptr&) @ 0x0000000015f9837e 21. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000165d6fc3 22. /build/src/Storages/StorageReplicatedMergeTree.cpp:3872: DB::StorageReplicatedMergeTree::processQueueEntry(std::shared_ptr) @ 0x0000000015efc18a 23. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001624c1b2 24. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000162f9c70 25. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x00000000162fa55a 26. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc6653 27. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000000fccc4c3 28. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc3d92 29. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fcca080 30. ? @ 0x00007fbc6213eac3 31. ? @ 0x00007fbc621d0850 (version 25.3.6.10636.altinitytest (altinity build)) 2025.07.28 11:58:14.603186 [ 17191 ] {} 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. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception>&, String>(int, FormatStringHelperImpl>&>::type, std::type_identity::type>, std::basic_string_view>&, String&&) @ 0x000000001385a5eb 4. /build/src/Access/SettingsConstraints.cpp:376: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000013859b18 5. /build/src/Access/SettingsConstraints.cpp:300: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000013858faf 6. /build/src/Access/SettingsConstraints.cpp:209: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000013859223 7. /build/src/Interpreters/Context.cpp:2690: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000014436134 8. /build/src/Interpreters/Context.cpp:2729: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x000000001443662b 9. /build/src/Server/HTTPHandler.cpp:457: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000001686d165 10. /build/src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x0000000016870807 11. /build/src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x0000000016907e99 12. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 13. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 14. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 15. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 16. ? @ 0x00007fbc6213eac3 17. ? @ 0x00007fbc621d0850 (version 25.3.6.10636.altinitytest (altinity build)) 2025.07.28 11:58:15.262685 [ 3977 ] {} test_13.rmt2 (7f9b740d-015c-470e-8cc6-8ba33be0dc63): auto DB::StorageReplicatedMergeTree::processQueueEntry(ReplicatedMergeTreeQueue::SelectedEntryPtr)::(anonymous class)::operator()(LogEntryPtr &) const: Code: 86. DB::HTTPException: Received error from remote server http://146b4357c08d:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Ftest%2F01165%2Ftest_13%2Frmt%2Freplicas%2F1&part=20250728_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.6.10636.altinitytest (altinity build)) '. (RECEIVED_ERROR_FROM_REMOTE_IO_SERVER), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.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 const&, int&&, String const&, unsigned long&&, String const&) @ 0x000000000feda8d9 4. /build/src/IO/HTTPCommon.cpp:104: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x000000000feda6e2 5. /build/src/IO/HTTPCommon.cpp:93: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x000000000feda537 6. /build/src/IO/ReadWriteBufferFromHTTP.cpp:277: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x000000001184a4c4 7. /build/src/IO/ReadWriteBufferFromHTTP.cpp:285: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x000000001184a615 8. /build/src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x000000001184ae59 9. /build/src/IO/ReadWriteBufferFromHTTP.cpp:472: void std::__function::__policy_invoker::__call_impl[abi:se190107]>(std::__function::__policy_storage const*) @ 0x000000001184cedd 10. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001184858b 11. /build/src/IO/ReadWriteBufferFromHTTP.cpp:465: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x000000001184bf0b 12. /build/src/IO/ReadBuffer.h:60: DB::ReadBuffer::next() @ 0x000000000a148c7b 13. /build/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) @ 0x0000000011849fb2 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]>&)>&, 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&) @ 0x0000000011841980 15. /build/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) @ 0x000000001621208e 16. /build/src/Storages/StorageReplicatedMergeTree.cpp:5228: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl[abi:se190107] const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000015f9a5fe 17. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000015ed8bfd 18. /build/src/Storages/StorageReplicatedMergeTree.cpp:2514: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x0000000015ec9aab 19. /build/src/Storages/StorageReplicatedMergeTree.cpp:2349: DB::StorageReplicatedMergeTree::executeLogEntry(DB::ReplicatedMergeTreeLogEntry&) @ 0x0000000015eba91b 20. /build/src/Storages/StorageReplicatedMergeTree.cpp:3876: bool std::__function::__policy_invoker&)>::__call_impl[abi:se190107])::$_1, bool (std::shared_ptr&)>>(std::__function::__policy_storage const*, std::shared_ptr&) @ 0x0000000015f9837e 21. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000165d6fc3 22. /build/src/Storages/StorageReplicatedMergeTree.cpp:3872: DB::StorageReplicatedMergeTree::processQueueEntry(std::shared_ptr) @ 0x0000000015efc18a 23. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001624c1b2 24. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000162f9c70 25. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x00000000162fa55a 26. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc6653 27. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000000fccc4c3 28. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc3d92 29. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fcca080 30. ? @ 0x00007fbc6213eac3 31. ? @ 0x00007fbc621d0850 (version 25.3.6.10636.altinitytest (altinity build)) 2025.07.28 11:58:15.290470 [ 3950 ] {14a582aa-ce40-45df-9282-1c188b4c4b61::all_1_1_0_2} MutatePlainMergeTreeTask: Code: 60. DB::Exception: Table test_m5vv2z8y.t1 does not exist. Maybe you meant test_m5vv2z8y.t0?: While processing _CAST(_CAST(1 IN ((SELECT 1 FROM (SELECT 1 FROM test_m5vv2z8y.t1 CROSS JOIN test_m5vv2z8y.t0) LIMIT 1) AS _subquery25), 'Int32'), 'Int32'). (UNKNOWN_TABLE) (version 25.3.6.10636.altinitytest (altinity build)) 2025.07.28 11:58:15.318547 [ 3950 ] {14a582aa-ce40-45df-9282-1c188b4c4b61::all_1_1_0_2} virtual bool DB::MutatePlainMergeTreeTask::executeStep(): Code: 60. DB::Exception: Table test_m5vv2z8y.t1 does not exist. Maybe you meant test_m5vv2z8y.t0?: While processing _CAST(_CAST(1 IN ((SELECT 1 FROM (SELECT 1 FROM test_m5vv2z8y.t1 CROSS JOIN test_m5vv2z8y.t0) LIMIT 1) AS _subquery25), 'Int32'), 'Int32'). (UNKNOWN_TABLE), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/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&&) @ 0x000000000a1011eb 4. /build/src/Databases/IDatabase.cpp:42: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x0000000013dd57aa 5. /build/src/Interpreters/DatabaseCatalog.cpp:442: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x00000000144f0869 6. /build/src/Interpreters/DatabaseCatalog.cpp:976: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x00000000144f6c88 7. /build/src/Interpreters/JoinedTables.cpp:245: DB::JoinedTables::getLeftTableStorage() @ 0x0000000014a0008b 8. /build/src/Interpreters/InterpreterSelectQuery.cpp:561: 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) @ 0x000000001494125f 9. /build/src/Interpreters/InterpreterSelectQuery.cpp:311: DB::InterpreterSelectQuery::InterpreterSelectQuery(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x00000000149409b1 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: DB::InterpreterSelectWithUnionQuery::buildCurrentChildInterpreter(std::shared_ptr const&, std::vector> const&) @ 0x00000000149dc655 11. /build/src/Interpreters/InterpreterSelectWithUnionQuery.cpp:167: DB::InterpreterSelectWithUnionQuery::InterpreterSelectWithUnionQuery(std::shared_ptr const&, std::shared_ptr, DB::SelectQueryOptions const&, std::vector> const&) @ 0x00000000149db13f 12. /build/src/Interpreters/InterpreterSelectWithUnionQuery.cpp:56: DB::InterpreterSelectWithUnionQuery::InterpreterSelectWithUnionQuery(std::shared_ptr const&, std::shared_ptr, DB::SelectQueryOptions const&, std::vector> const&) @ 0x00000000149da0c2 13. /build/src/Interpreters/InterpreterSelectWithUnionQuery.cpp:299: DB::InterpreterSelectWithUnionQuery::getSampleBlock(std::shared_ptr const&, std::shared_ptr, bool, bool) @ 0x00000000149dd13a 14. /build/src/Interpreters/getTableExpressions.cpp:91: DB::getDatabaseAndTablesWithColumns(std::vector> const&, std::shared_ptr, bool, bool, bool) @ 0x0000000014c9fc80 15. /build/src/Interpreters/JoinedTables.cpp:253: DB::JoinedTables::resolveTables() @ 0x0000000014a0030c 16. /build/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) @ 0x000000001494171f 17. /build/src/Interpreters/InterpreterSelectQuery.cpp:311: DB::InterpreterSelectQuery::InterpreterSelectQuery(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x00000000149409b1 18. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: DB::InterpreterSelectWithUnionQuery::buildCurrentChildInterpreter(std::shared_ptr const&, std::vector> const&) @ 0x00000000149dc655 19. /build/src/Interpreters/InterpreterSelectWithUnionQuery.cpp:167: DB::InterpreterSelectWithUnionQuery::InterpreterSelectWithUnionQuery(std::shared_ptr const&, std::shared_ptr, DB::SelectQueryOptions const&, std::vector> const&) @ 0x00000000149db13f 20. /build/contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: DB::interpretSubquery(std::shared_ptr const&, std::shared_ptr, std::vector> const&, DB::SelectQueryOptions const&) @ 0x0000000014ca568d 21. /build/src/Interpreters/interpretSubquery.cpp:37: DB::interpretSubquery(std::shared_ptr const&, std::shared_ptr, unsigned long, std::vector> const&) @ 0x0000000014ca49c5 22. /build/src/Interpreters/ActionsVisitor.cpp:1516: DB::ActionsMatcher::makeSet(DB::ASTFunction const&, DB::ActionsMatcher::Data&, bool) @ 0x000000001455d045 23. /build/src/Interpreters/ActionsVisitor.cpp:999: DB::ActionsMatcher::visit(DB::ASTFunction const&, std::shared_ptr const&, DB::ActionsMatcher::Data&) @ 0x0000000014554175 24. /build/src/Interpreters/ActionsVisitor.cpp:1279: DB::ActionsMatcher::visit(DB::ASTFunction const&, std::shared_ptr const&, DB::ActionsMatcher::Data&) @ 0x0000000014555bfa 25. /build/src/Interpreters/ActionsVisitor.cpp:1279: DB::ActionsMatcher::visit(DB::ASTFunction const&, std::shared_ptr const&, DB::ActionsMatcher::Data&) @ 0x0000000014555bfa 26. /build/src/Interpreters/InDepthNodeVisitor.h:71: DB::InDepthNodeVisitor const>::doVisit(std::shared_ptr const&) @ 0x000000001454b195 27. /build/src/Interpreters/InDepthNodeVisitor.h:61: DB::ExpressionAnalyzer::getRootActions(std::shared_ptr const&, bool, DB::ActionsDAG&, bool) @ 0x0000000014528f28 28. /build/src/Interpreters/ExpressionAnalyzer.cpp:1840: DB::ExpressionAnalyzer::appendExpression(DB::ExpressionActionsChain&, std::shared_ptr const&, bool) @ 0x0000000014537d38 29. /build/src/Interpreters/MutationsInterpreter.cpp:1205: DB::MutationsInterpreter::prepareMutationStages(std::vector>&, bool) @ 0x0000000014a2e1a0 30. /build/src/Interpreters/MutationsInterpreter.cpp:1095: DB::MutationsInterpreter::prepare(bool) @ 0x0000000014a2abed 31. /build/src/Interpreters/MutationsInterpreter.cpp:432: DB::MutationsInterpreter::MutationsInterpreter(DB::MergeTreeData&, std::shared_ptr, std::shared_ptr, std::shared_ptr, DB::MutationCommands, std::vector>, std::shared_ptr, DB::MutationsInterpreter::Settings) @ 0x0000000014a2cd17 (version 25.3.6.10636.altinitytest (altinity build)) 2025.07.28 11:58:15.320194 [ 3950 ] {} MergeTreeBackgroundExecutor: Exception while executing background task {14a582aa-ce40-45df-9282-1c188b4c4b61::all_1_1_0_2}: Code: 60. DB::Exception: Table test_m5vv2z8y.t1 does not exist. Maybe you meant test_m5vv2z8y.t0?: While processing _CAST(_CAST(1 IN ((SELECT 1 FROM (SELECT 1 FROM test_m5vv2z8y.t1 CROSS JOIN test_m5vv2z8y.t0) LIMIT 1) AS _subquery25), 'Int32'), 'Int32'). (UNKNOWN_TABLE), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/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&&) @ 0x000000000a1011eb 4. /build/src/Databases/IDatabase.cpp:42: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x0000000013dd57aa 5. /build/src/Interpreters/DatabaseCatalog.cpp:442: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x00000000144f0869 6. /build/src/Interpreters/DatabaseCatalog.cpp:976: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x00000000144f6c88 7. /build/src/Interpreters/JoinedTables.cpp:245: DB::JoinedTables::getLeftTableStorage() @ 0x0000000014a0008b 8. /build/src/Interpreters/InterpreterSelectQuery.cpp:561: 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) @ 0x000000001494125f 9. /build/src/Interpreters/InterpreterSelectQuery.cpp:311: DB::InterpreterSelectQuery::InterpreterSelectQuery(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x00000000149409b1 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: DB::InterpreterSelectWithUnionQuery::buildCurrentChildInterpreter(std::shared_ptr const&, std::vector> const&) @ 0x00000000149dc655 11. /build/src/Interpreters/InterpreterSelectWithUnionQuery.cpp:167: DB::InterpreterSelectWithUnionQuery::InterpreterSelectWithUnionQuery(std::shared_ptr const&, std::shared_ptr, DB::SelectQueryOptions const&, std::vector> const&) @ 0x00000000149db13f 12. /build/src/Interpreters/InterpreterSelectWithUnionQuery.cpp:56: DB::InterpreterSelectWithUnionQuery::InterpreterSelectWithUnionQuery(std::shared_ptr const&, std::shared_ptr, DB::SelectQueryOptions const&, std::vector> const&) @ 0x00000000149da0c2 13. /build/src/Interpreters/InterpreterSelectWithUnionQuery.cpp:299: DB::InterpreterSelectWithUnionQuery::getSampleBlock(std::shared_ptr const&, std::shared_ptr, bool, bool) @ 0x00000000149dd13a 14. /build/src/Interpreters/getTableExpressions.cpp:91: DB::getDatabaseAndTablesWithColumns(std::vector> const&, std::shared_ptr, bool, bool, bool) @ 0x0000000014c9fc80 15. /build/src/Interpreters/JoinedTables.cpp:253: DB::JoinedTables::resolveTables() @ 0x0000000014a0030c 16. /build/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) @ 0x000000001494171f 17. /build/src/Interpreters/InterpreterSelectQuery.cpp:311: DB::InterpreterSelectQuery::InterpreterSelectQuery(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x00000000149409b1 18. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: DB::InterpreterSelectWithUnionQuery::buildCurrentChildInterpreter(std::shared_ptr const&, std::vector> const&) @ 0x00000000149dc655 19. /build/src/Interpreters/InterpreterSelectWithUnionQuery.cpp:167: DB::InterpreterSelectWithUnionQuery::InterpreterSelectWithUnionQuery(std::shared_ptr const&, std::shared_ptr, DB::SelectQueryOptions const&, std::vector> const&) @ 0x00000000149db13f 20. /build/contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: DB::interpretSubquery(std::shared_ptr const&, std::shared_ptr, std::vector> const&, DB::SelectQueryOptions const&) @ 0x0000000014ca568d 21. /build/src/Interpreters/interpretSubquery.cpp:37: DB::interpretSubquery(std::shared_ptr const&, std::shared_ptr, unsigned long, std::vector> const&) @ 0x0000000014ca49c5 22. /build/src/Interpreters/ActionsVisitor.cpp:1516: DB::ActionsMatcher::makeSet(DB::ASTFunction const&, DB::ActionsMatcher::Data&, bool) @ 0x000000001455d045 23. /build/src/Interpreters/ActionsVisitor.cpp:999: DB::ActionsMatcher::visit(DB::ASTFunction const&, std::shared_ptr const&, DB::ActionsMatcher::Data&) @ 0x0000000014554175 24. /build/src/Interpreters/ActionsVisitor.cpp:1279: DB::ActionsMatcher::visit(DB::ASTFunction const&, std::shared_ptr const&, DB::ActionsMatcher::Data&) @ 0x0000000014555bfa 25. /build/src/Interpreters/ActionsVisitor.cpp:1279: DB::ActionsMatcher::visit(DB::ASTFunction const&, std::shared_ptr const&, DB::ActionsMatcher::Data&) @ 0x0000000014555bfa 26. /build/src/Interpreters/InDepthNodeVisitor.h:71: DB::InDepthNodeVisitor const>::doVisit(std::shared_ptr const&) @ 0x000000001454b195 27. /build/src/Interpreters/InDepthNodeVisitor.h:61: DB::ExpressionAnalyzer::getRootActions(std::shared_ptr const&, bool, DB::ActionsDAG&, bool) @ 0x0000000014528f28 28. /build/src/Interpreters/ExpressionAnalyzer.cpp:1840: DB::ExpressionAnalyzer::appendExpression(DB::ExpressionActionsChain&, std::shared_ptr const&, bool) @ 0x0000000014537d38 29. /build/src/Interpreters/MutationsInterpreter.cpp:1205: DB::MutationsInterpreter::prepareMutationStages(std::vector>&, bool) @ 0x0000000014a2e1a0 30. /build/src/Interpreters/MutationsInterpreter.cpp:1095: DB::MutationsInterpreter::prepare(bool) @ 0x0000000014a2abed 31. /build/src/Interpreters/MutationsInterpreter.cpp:432: DB::MutationsInterpreter::MutationsInterpreter(DB::MergeTreeData&, std::shared_ptr, std::shared_ptr, std::shared_ptr, DB::MutationCommands, std::vector>, std::shared_ptr, DB::MutationsInterpreter::Settings) @ 0x0000000014a2cd17 (version 25.3.6.10636.altinitytest (altinity build)) 2025.07.28 11:58:16.189980 [ 5951 ] {dccf2f79-5087-461c-a52e-f8e5b07b9914} executeQuery: Code: 219. DB::Exception: New table appeared in database being dropped or detached. Try again. (DATABASE_NOT_EMPTY) (version 25.3.6.10636.altinitytest (altinity build)) (from [::1]:41990) (comment: 01018_Distributed__shard_num.sql) (in query: DROP DATABASE IF EXISTS test_g839ksfq SYNC ), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000000a074fcb 4. /build/src/Interpreters/DatabaseCatalog.cpp:608: DB::DatabaseCatalog::detachDatabase(std::shared_ptr, String const&, bool, bool) @ 0x00000000144f41b9 5. /build/src/Interpreters/InterpreterDropQuery.cpp:482: DB::InterpreterDropQuery::executeToDatabaseImpl(DB::ASTDropQuery const&, std::shared_ptr&, std::vector, DB::UUIDTag>, std::allocator, DB::UUIDTag>>>&) @ 0x00000000149179be 6. /build/src/Interpreters/InterpreterDropQuery.cpp:363: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x0000000014913988 7. /build/src/Interpreters/InterpreterDropQuery.cpp:99: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000014913142 8. /build/src/Interpreters/InterpreterDropQuery.cpp:72: DB::InterpreterDropQuery::execute() @ 0x0000000014912b65 9. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88dc9 10. /build/src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x0000000014c8ca7b 11. /build/src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000001686da12 12. /build/src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x0000000016870807 13. /build/src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x0000000016907e99 14. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 15. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 16. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 17. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 18. ? @ 0x00007fbc6213eac3 19. ? @ 0x00007fbc621d0850 2025.07.28 11:58:16.191456 [ 5951 ] {dccf2f79-5087-461c-a52e-f8e5b07b9914} 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. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000000a074fcb 4. /build/src/Interpreters/DatabaseCatalog.cpp:608: DB::DatabaseCatalog::detachDatabase(std::shared_ptr, String const&, bool, bool) @ 0x00000000144f41b9 5. /build/src/Interpreters/InterpreterDropQuery.cpp:482: DB::InterpreterDropQuery::executeToDatabaseImpl(DB::ASTDropQuery const&, std::shared_ptr&, std::vector, DB::UUIDTag>, std::allocator, DB::UUIDTag>>>&) @ 0x00000000149179be 6. /build/src/Interpreters/InterpreterDropQuery.cpp:363: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x0000000014913988 7. /build/src/Interpreters/InterpreterDropQuery.cpp:99: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000014913142 8. /build/src/Interpreters/InterpreterDropQuery.cpp:72: DB::InterpreterDropQuery::execute() @ 0x0000000014912b65 9. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88dc9 10. /build/src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x0000000014c8ca7b 11. /build/src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000001686da12 12. /build/src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x0000000016870807 13. /build/src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x0000000016907e99 14. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 15. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 16. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 17. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 18. ? @ 0x00007fbc6213eac3 19. ? @ 0x00007fbc621d0850 (version 25.3.6.10636.altinitytest (altinity build)) 2025.07.28 11:58:16.205609 [ 3939 ] {14a582aa-ce40-45df-9282-1c188b4c4b61::all_1_1_0_3} MutatePlainMergeTreeTask: Code: 60. DB::Exception: Table test_m5vv2z8y.t1 does not exist. Maybe you meant test_m5vv2z8y.t0?: While processing _CAST(_CAST(1 IN ((SELECT 1 FROM (SELECT 1 FROM test_m5vv2z8y.t1 CROSS JOIN test_m5vv2z8y.t0) LIMIT 1) AS _subquery27), 'Dynamic'), 'Dynamic'). (UNKNOWN_TABLE) (version 25.3.6.10636.altinitytest (altinity build)) 2025.07.28 11:58:16.223885 [ 3939 ] {14a582aa-ce40-45df-9282-1c188b4c4b61::all_1_1_0_3} virtual bool DB::MutatePlainMergeTreeTask::executeStep(): Code: 60. DB::Exception: Table test_m5vv2z8y.t1 does not exist. Maybe you meant test_m5vv2z8y.t0?: While processing _CAST(_CAST(1 IN ((SELECT 1 FROM (SELECT 1 FROM test_m5vv2z8y.t1 CROSS JOIN test_m5vv2z8y.t0) LIMIT 1) AS _subquery27), 'Dynamic'), 'Dynamic'). (UNKNOWN_TABLE), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/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&&) @ 0x000000000a1011eb 4. /build/src/Databases/IDatabase.cpp:42: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x0000000013dd57aa 5. /build/src/Interpreters/DatabaseCatalog.cpp:442: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x00000000144f0869 6. /build/src/Interpreters/DatabaseCatalog.cpp:976: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x00000000144f6c88 7. /build/src/Interpreters/JoinedTables.cpp:245: DB::JoinedTables::getLeftTableStorage() @ 0x0000000014a0008b 8. /build/src/Interpreters/InterpreterSelectQuery.cpp:561: 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) @ 0x000000001494125f 9. /build/src/Interpreters/InterpreterSelectQuery.cpp:311: DB::InterpreterSelectQuery::InterpreterSelectQuery(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x00000000149409b1 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: DB::InterpreterSelectWithUnionQuery::buildCurrentChildInterpreter(std::shared_ptr const&, std::vector> const&) @ 0x00000000149dc655 11. /build/src/Interpreters/InterpreterSelectWithUnionQuery.cpp:167: DB::InterpreterSelectWithUnionQuery::InterpreterSelectWithUnionQuery(std::shared_ptr const&, std::shared_ptr, DB::SelectQueryOptions const&, std::vector> const&) @ 0x00000000149db13f 12. /build/src/Interpreters/InterpreterSelectWithUnionQuery.cpp:56: DB::InterpreterSelectWithUnionQuery::InterpreterSelectWithUnionQuery(std::shared_ptr const&, std::shared_ptr, DB::SelectQueryOptions const&, std::vector> const&) @ 0x00000000149da0c2 13. /build/src/Interpreters/InterpreterSelectWithUnionQuery.cpp:299: DB::InterpreterSelectWithUnionQuery::getSampleBlock(std::shared_ptr const&, std::shared_ptr, bool, bool) @ 0x00000000149dd13a 14. /build/src/Interpreters/getTableExpressions.cpp:91: DB::getDatabaseAndTablesWithColumns(std::vector> const&, std::shared_ptr, bool, bool, bool) @ 0x0000000014c9fc80 15. /build/src/Interpreters/JoinedTables.cpp:253: DB::JoinedTables::resolveTables() @ 0x0000000014a0030c 16. /build/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) @ 0x000000001494171f 17. /build/src/Interpreters/InterpreterSelectQuery.cpp:311: DB::InterpreterSelectQuery::InterpreterSelectQuery(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x00000000149409b1 18. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: DB::InterpreterSelectWithUnionQuery::buildCurrentChildInterpreter(std::shared_ptr const&, std::vector> const&) @ 0x00000000149dc655 19. /build/src/Interpreters/InterpreterSelectWithUnionQuery.cpp:167: DB::InterpreterSelectWithUnionQuery::InterpreterSelectWithUnionQuery(std::shared_ptr const&, std::shared_ptr, DB::SelectQueryOptions const&, std::vector> const&) @ 0x00000000149db13f 20. /build/contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: DB::interpretSubquery(std::shared_ptr const&, std::shared_ptr, std::vector> const&, DB::SelectQueryOptions const&) @ 0x0000000014ca568d 21. /build/src/Interpreters/interpretSubquery.cpp:37: DB::interpretSubquery(std::shared_ptr const&, std::shared_ptr, unsigned long, std::vector> const&) @ 0x0000000014ca49c5 22. /build/src/Interpreters/ActionsVisitor.cpp:1516: DB::ActionsMatcher::makeSet(DB::ASTFunction const&, DB::ActionsMatcher::Data&, bool) @ 0x000000001455d045 23. /build/src/Interpreters/ActionsVisitor.cpp:999: DB::ActionsMatcher::visit(DB::ASTFunction const&, std::shared_ptr const&, DB::ActionsMatcher::Data&) @ 0x0000000014554175 24. /build/src/Interpreters/ActionsVisitor.cpp:1279: DB::ActionsMatcher::visit(DB::ASTFunction const&, std::shared_ptr const&, DB::ActionsMatcher::Data&) @ 0x0000000014555bfa 25. /build/src/Interpreters/ActionsVisitor.cpp:1279: DB::ActionsMatcher::visit(DB::ASTFunction const&, std::shared_ptr const&, DB::ActionsMatcher::Data&) @ 0x0000000014555bfa 26. /build/src/Interpreters/InDepthNodeVisitor.h:71: DB::InDepthNodeVisitor const>::doVisit(std::shared_ptr const&) @ 0x000000001454b195 27. /build/src/Interpreters/InDepthNodeVisitor.h:61: DB::ExpressionAnalyzer::getRootActions(std::shared_ptr const&, bool, DB::ActionsDAG&, bool) @ 0x0000000014528f28 28. /build/src/Interpreters/ExpressionAnalyzer.cpp:1840: DB::ExpressionAnalyzer::appendExpression(DB::ExpressionActionsChain&, std::shared_ptr const&, bool) @ 0x0000000014537d38 29. /build/src/Interpreters/MutationsInterpreter.cpp:1205: DB::MutationsInterpreter::prepareMutationStages(std::vector>&, bool) @ 0x0000000014a2e1a0 30. /build/src/Interpreters/MutationsInterpreter.cpp:1095: DB::MutationsInterpreter::prepare(bool) @ 0x0000000014a2abed 31. /build/src/Interpreters/MutationsInterpreter.cpp:432: DB::MutationsInterpreter::MutationsInterpreter(DB::MergeTreeData&, std::shared_ptr, std::shared_ptr, std::shared_ptr, DB::MutationCommands, std::vector>, std::shared_ptr, DB::MutationsInterpreter::Settings) @ 0x0000000014a2cd17 (version 25.3.6.10636.altinitytest (altinity build)) 2025.07.28 11:58:16.233014 [ 3939 ] {} MergeTreeBackgroundExecutor: Exception while executing background task {14a582aa-ce40-45df-9282-1c188b4c4b61::all_1_1_0_3}: Code: 60. DB::Exception: Table test_m5vv2z8y.t1 does not exist. Maybe you meant test_m5vv2z8y.t0?: While processing _CAST(_CAST(1 IN ((SELECT 1 FROM (SELECT 1 FROM test_m5vv2z8y.t1 CROSS JOIN test_m5vv2z8y.t0) LIMIT 1) AS _subquery27), 'Dynamic'), 'Dynamic'). (UNKNOWN_TABLE), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/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&&) @ 0x000000000a1011eb 4. /build/src/Databases/IDatabase.cpp:42: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x0000000013dd57aa 5. /build/src/Interpreters/DatabaseCatalog.cpp:442: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x00000000144f0869 6. /build/src/Interpreters/DatabaseCatalog.cpp:976: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x00000000144f6c88 7. /build/src/Interpreters/JoinedTables.cpp:245: DB::JoinedTables::getLeftTableStorage() @ 0x0000000014a0008b 8. /build/src/Interpreters/InterpreterSelectQuery.cpp:561: 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) @ 0x000000001494125f 9. /build/src/Interpreters/InterpreterSelectQuery.cpp:311: DB::InterpreterSelectQuery::InterpreterSelectQuery(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x00000000149409b1 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: DB::InterpreterSelectWithUnionQuery::buildCurrentChildInterpreter(std::shared_ptr const&, std::vector> const&) @ 0x00000000149dc655 11. /build/src/Interpreters/InterpreterSelectWithUnionQuery.cpp:167: DB::InterpreterSelectWithUnionQuery::InterpreterSelectWithUnionQuery(std::shared_ptr const&, std::shared_ptr, DB::SelectQueryOptions const&, std::vector> const&) @ 0x00000000149db13f 12. /build/src/Interpreters/InterpreterSelectWithUnionQuery.cpp:56: DB::InterpreterSelectWithUnionQuery::InterpreterSelectWithUnionQuery(std::shared_ptr const&, std::shared_ptr, DB::SelectQueryOptions const&, std::vector> const&) @ 0x00000000149da0c2 13. /build/src/Interpreters/InterpreterSelectWithUnionQuery.cpp:299: DB::InterpreterSelectWithUnionQuery::getSampleBlock(std::shared_ptr const&, std::shared_ptr, bool, bool) @ 0x00000000149dd13a 14. /build/src/Interpreters/getTableExpressions.cpp:91: DB::getDatabaseAndTablesWithColumns(std::vector> const&, std::shared_ptr, bool, bool, bool) @ 0x0000000014c9fc80 15. /build/src/Interpreters/JoinedTables.cpp:253: DB::JoinedTables::resolveTables() @ 0x0000000014a0030c 16. /build/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) @ 0x000000001494171f 17. /build/src/Interpreters/InterpreterSelectQuery.cpp:311: DB::InterpreterSelectQuery::InterpreterSelectQuery(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x00000000149409b1 18. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: DB::InterpreterSelectWithUnionQuery::buildCurrentChildInterpreter(std::shared_ptr const&, std::vector> const&) @ 0x00000000149dc655 19. /build/src/Interpreters/InterpreterSelectWithUnionQuery.cpp:167: DB::InterpreterSelectWithUnionQuery::InterpreterSelectWithUnionQuery(std::shared_ptr const&, std::shared_ptr, DB::SelectQueryOptions const&, std::vector> const&) @ 0x00000000149db13f 20. /build/contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: DB::interpretSubquery(std::shared_ptr const&, std::shared_ptr, std::vector> const&, DB::SelectQueryOptions const&) @ 0x0000000014ca568d 21. /build/src/Interpreters/interpretSubquery.cpp:37: DB::interpretSubquery(std::shared_ptr const&, std::shared_ptr, unsigned long, std::vector> const&) @ 0x0000000014ca49c5 22. /build/src/Interpreters/ActionsVisitor.cpp:1516: DB::ActionsMatcher::makeSet(DB::ASTFunction const&, DB::ActionsMatcher::Data&, bool) @ 0x000000001455d045 23. /build/src/Interpreters/ActionsVisitor.cpp:999: DB::ActionsMatcher::visit(DB::ASTFunction const&, std::shared_ptr const&, DB::ActionsMatcher::Data&) @ 0x0000000014554175 24. /build/src/Interpreters/ActionsVisitor.cpp:1279: DB::ActionsMatcher::visit(DB::ASTFunction const&, std::shared_ptr const&, DB::ActionsMatcher::Data&) @ 0x0000000014555bfa 25. /build/src/Interpreters/ActionsVisitor.cpp:1279: DB::ActionsMatcher::visit(DB::ASTFunction const&, std::shared_ptr const&, DB::ActionsMatcher::Data&) @ 0x0000000014555bfa 26. /build/src/Interpreters/InDepthNodeVisitor.h:71: DB::InDepthNodeVisitor const>::doVisit(std::shared_ptr const&) @ 0x000000001454b195 27. /build/src/Interpreters/InDepthNodeVisitor.h:61: DB::ExpressionAnalyzer::getRootActions(std::shared_ptr const&, bool, DB::ActionsDAG&, bool) @ 0x0000000014528f28 28. /build/src/Interpreters/ExpressionAnalyzer.cpp:1840: DB::ExpressionAnalyzer::appendExpression(DB::ExpressionActionsChain&, std::shared_ptr const&, bool) @ 0x0000000014537d38 29. /build/src/Interpreters/MutationsInterpreter.cpp:1205: DB::MutationsInterpreter::prepareMutationStages(std::vector>&, bool) @ 0x0000000014a2e1a0 30. /build/src/Interpreters/MutationsInterpreter.cpp:1095: DB::MutationsInterpreter::prepare(bool) @ 0x0000000014a2abed 31. /build/src/Interpreters/MutationsInterpreter.cpp:432: DB::MutationsInterpreter::MutationsInterpreter(DB::MergeTreeData&, std::shared_ptr, std::shared_ptr, std::shared_ptr, DB::MutationCommands, std::vector>, std::shared_ptr, DB::MutationsInterpreter::Settings) @ 0x0000000014a2cd17 (version 25.3.6.10636.altinitytest (altinity build)) 2025.07.28 11:58:16.258835 [ 17208 ] {8411b813-350e-42d2-904d-9ab582f2eb4f} executeQuery: Code: 341. DB::Exception: Exception happened during execution of mutations 'mutation_2.txt, mutation_3.txt' with part 'all_1_1_0' reason: 'Code: 60. DB::Exception: Table test_m5vv2z8y.t1 does not exist. Maybe you meant test_m5vv2z8y.t0?: While processing _CAST(_CAST(1 IN ((SELECT 1 FROM (SELECT 1 FROM test_m5vv2z8y.t1 CROSS JOIN test_m5vv2z8y.t0) LIMIT 1) AS _subquery27), 'Dynamic'), 'Dynamic'). (UNKNOWN_TABLE) (version 25.3.6.10636.altinitytest (altinity build))'. This error maybe retryable or not. In case of unretryable error, mutation can be killed with KILL MUTATION query 0. /build/src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000000fc33b84 1. /build/src/Storages/MergeTree/MergeTreeMutationStatus.cpp:33: DB::checkMutationStatus(std::optional&, std::set, std::allocator> const&) @ 0x0000000016476d6e 2. /build/src/Storages/StorageMergeTree.cpp:678: DB::StorageMergeTree::waitForMutation(long, String const&, bool) @ 0x0000000016639a48 3. /build/src/Storages/StorageMergeTree.cpp:648: DB::StorageMergeTree::alter(DB::AlterCommands const&, std::shared_ptr, std::unique_lock&) @ 0x00000000166369ee 4. /build/src/Interpreters/InterpreterAlterQuery.cpp:216: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x00000000148deae5 5. /build/src/Interpreters/InterpreterAlterQuery.cpp:77: DB::InterpreterAlterQuery::execute() @ 0x00000000148dcb0d 6. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88dc9 7. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 8. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 9. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 10. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 11. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 12. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 13. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 14. ? @ 0x00007fbc6213eac3 15. ? @ 0x00007fbc621d0850 . (UNFINISHED) (version 25.3.6.10636.altinitytest (altinity build)) (from [::1]:59678) (comment: 03246_alter_update_dynamic_hung.sql) (query 6, line 6) (in query: ALTER TABLE t0 MODIFY COLUMN c0 Dynamic;), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.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&&) @ 0x0000000016476eb9 4. /build/src/Storages/MergeTree/MergeTreeMutationStatus.cpp:26: DB::checkMutationStatus(std::optional&, std::set, std::allocator> const&) @ 0x0000000016476dcd 5. /build/src/Storages/StorageMergeTree.cpp:678: DB::StorageMergeTree::waitForMutation(long, String const&, bool) @ 0x0000000016639a48 6. /build/src/Storages/StorageMergeTree.cpp:648: DB::StorageMergeTree::alter(DB::AlterCommands const&, std::shared_ptr, std::unique_lock&) @ 0x00000000166369ee 7. /build/src/Interpreters/InterpreterAlterQuery.cpp:216: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x00000000148deae5 8. /build/src/Interpreters/InterpreterAlterQuery.cpp:77: DB::InterpreterAlterQuery::execute() @ 0x00000000148dcb0d 9. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88dc9 10. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 11. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 12. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 13. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 14. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 16. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 17. ? @ 0x00007fbc6213eac3 18. ? @ 0x00007fbc621d0850 2025.07.28 11:58:16.269288 [ 17208 ] {} TCPHandler: Code: 341. DB::Exception: Exception happened during execution of mutations 'mutation_2.txt, mutation_3.txt' with part 'all_1_1_0' reason: 'Code: 60. DB::Exception: Table test_m5vv2z8y.t1 does not exist. Maybe you meant test_m5vv2z8y.t0?: While processing _CAST(_CAST(1 IN ((SELECT 1 FROM (SELECT 1 FROM test_m5vv2z8y.t1 CROSS JOIN test_m5vv2z8y.t0) LIMIT 1) AS _subquery27), 'Dynamic'), 'Dynamic'). (UNKNOWN_TABLE) (version 25.3.6.10636.altinitytest (altinity build))'. This error maybe retryable or not. In case of unretryable error, mutation can be killed with KILL MUTATION query 0. /build/src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000000fc33b84 1. /build/src/Storages/MergeTree/MergeTreeMutationStatus.cpp:33: DB::checkMutationStatus(std::optional&, std::set, std::allocator> const&) @ 0x0000000016476d6e 2. /build/src/Storages/StorageMergeTree.cpp:678: DB::StorageMergeTree::waitForMutation(long, String const&, bool) @ 0x0000000016639a48 3. /build/src/Storages/StorageMergeTree.cpp:648: DB::StorageMergeTree::alter(DB::AlterCommands const&, std::shared_ptr, std::unique_lock&) @ 0x00000000166369ee 4. /build/src/Interpreters/InterpreterAlterQuery.cpp:216: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x00000000148deae5 5. /build/src/Interpreters/InterpreterAlterQuery.cpp:77: DB::InterpreterAlterQuery::execute() @ 0x00000000148dcb0d 6. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88dc9 7. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 8. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 9. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 10. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 11. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 12. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 13. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 14. ? @ 0x00007fbc6213eac3 15. ? @ 0x00007fbc621d0850 . (UNFINISHED), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.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&&) @ 0x0000000016476eb9 4. /build/src/Storages/MergeTree/MergeTreeMutationStatus.cpp:26: DB::checkMutationStatus(std::optional&, std::set, std::allocator> const&) @ 0x0000000016476dcd 5. /build/src/Storages/StorageMergeTree.cpp:678: DB::StorageMergeTree::waitForMutation(long, String const&, bool) @ 0x0000000016639a48 6. /build/src/Storages/StorageMergeTree.cpp:648: DB::StorageMergeTree::alter(DB::AlterCommands const&, std::shared_ptr, std::unique_lock&) @ 0x00000000166369ee 7. /build/src/Interpreters/InterpreterAlterQuery.cpp:216: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x00000000148deae5 8. /build/src/Interpreters/InterpreterAlterQuery.cpp:77: DB::InterpreterAlterQuery::execute() @ 0x00000000148dcb0d 9. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88dc9 10. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 11. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 12. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 13. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 14. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 16. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 17. ? @ 0x00007fbc6213eac3 18. ? @ 0x00007fbc621d0850 2025.07.28 11:58:16.338874 [ 3965 ] {} test_13.rmt2 (7f9b740d-015c-470e-8cc6-8ba33be0dc63): auto DB::StorageReplicatedMergeTree::processQueueEntry(ReplicatedMergeTreeQueue::SelectedEntryPtr)::(anonymous class)::operator()(LogEntryPtr &) const: Code: 86. DB::HTTPException: Received error from remote server http://146b4357c08d:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Ftest%2F01165%2Ftest_13%2Frmt%2Freplicas%2F1&part=20250728_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.6.10636.altinitytest (altinity build)) '. (RECEIVED_ERROR_FROM_REMOTE_IO_SERVER), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.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 const&, int&&, String const&, unsigned long&&, String const&) @ 0x000000000feda8d9 4. /build/src/IO/HTTPCommon.cpp:104: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x000000000feda6e2 5. /build/src/IO/HTTPCommon.cpp:93: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x000000000feda537 6. /build/src/IO/ReadWriteBufferFromHTTP.cpp:277: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x000000001184a4c4 7. /build/src/IO/ReadWriteBufferFromHTTP.cpp:285: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x000000001184a615 8. /build/src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x000000001184ae59 9. /build/src/IO/ReadWriteBufferFromHTTP.cpp:472: void std::__function::__policy_invoker::__call_impl[abi:se190107]>(std::__function::__policy_storage const*) @ 0x000000001184cedd 10. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001184858b 11. /build/src/IO/ReadWriteBufferFromHTTP.cpp:465: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x000000001184bf0b 12. /build/src/IO/ReadBuffer.h:60: DB::ReadBuffer::next() @ 0x000000000a148c7b 13. /build/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) @ 0x0000000011849fb2 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]>&)>&, 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&) @ 0x0000000011841980 15. /build/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) @ 0x000000001621208e 16. /build/src/Storages/StorageReplicatedMergeTree.cpp:5228: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl[abi:se190107] const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000015f9a5fe 17. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000015ed8bfd 18. /build/src/Storages/StorageReplicatedMergeTree.cpp:2514: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x0000000015ec9aab 19. /build/src/Storages/StorageReplicatedMergeTree.cpp:2349: DB::StorageReplicatedMergeTree::executeLogEntry(DB::ReplicatedMergeTreeLogEntry&) @ 0x0000000015eba91b 20. /build/src/Storages/StorageReplicatedMergeTree.cpp:3876: bool std::__function::__policy_invoker&)>::__call_impl[abi:se190107])::$_1, bool (std::shared_ptr&)>>(std::__function::__policy_storage const*, std::shared_ptr&) @ 0x0000000015f9837e 21. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000165d6fc3 22. /build/src/Storages/StorageReplicatedMergeTree.cpp:3872: DB::StorageReplicatedMergeTree::processQueueEntry(std::shared_ptr) @ 0x0000000015efc18a 23. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001624c1b2 24. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000162f9c70 25. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x00000000162fa55a 26. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc6653 27. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000000fccc4c3 28. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc3d92 29. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fcca080 30. ? @ 0x00007fbc6213eac3 31. ? @ 0x00007fbc621d0850 (version 25.3.6.10636.altinitytest (altinity build)) 2025.07.28 11:58:17.083903 [ 3961 ] {} test_13.rmt2 (7f9b740d-015c-470e-8cc6-8ba33be0dc63): auto DB::StorageReplicatedMergeTree::processQueueEntry(ReplicatedMergeTreeQueue::SelectedEntryPtr)::(anonymous class)::operator()(LogEntryPtr &) const: Code: 86. DB::HTTPException: Received error from remote server http://146b4357c08d:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Ftest%2F01165%2Ftest_13%2Frmt%2Freplicas%2F1&part=20250728_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.6.10636.altinitytest (altinity build)) '. (RECEIVED_ERROR_FROM_REMOTE_IO_SERVER), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.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 const&, int&&, String const&, unsigned long&&, String const&) @ 0x000000000feda8d9 4. /build/src/IO/HTTPCommon.cpp:104: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x000000000feda6e2 5. /build/src/IO/HTTPCommon.cpp:93: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x000000000feda537 6. /build/src/IO/ReadWriteBufferFromHTTP.cpp:277: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x000000001184a4c4 7. /build/src/IO/ReadWriteBufferFromHTTP.cpp:285: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x000000001184a615 8. /build/src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x000000001184ae59 9. /build/src/IO/ReadWriteBufferFromHTTP.cpp:472: void std::__function::__policy_invoker::__call_impl[abi:se190107]>(std::__function::__policy_storage const*) @ 0x000000001184cedd 10. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001184858b 11. /build/src/IO/ReadWriteBufferFromHTTP.cpp:465: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x000000001184bf0b 12. /build/src/IO/ReadBuffer.h:60: DB::ReadBuffer::next() @ 0x000000000a148c7b 13. /build/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) @ 0x0000000011849fb2 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]>&)>&, 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&) @ 0x0000000011841980 15. /build/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) @ 0x000000001621208e 16. /build/src/Storages/StorageReplicatedMergeTree.cpp:5228: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl[abi:se190107] const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000015f9a5fe 17. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000015ed8bfd 18. /build/src/Storages/StorageReplicatedMergeTree.cpp:2514: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x0000000015ec9aab 19. /build/src/Storages/StorageReplicatedMergeTree.cpp:2349: DB::StorageReplicatedMergeTree::executeLogEntry(DB::ReplicatedMergeTreeLogEntry&) @ 0x0000000015eba91b 20. /build/src/Storages/StorageReplicatedMergeTree.cpp:3876: bool std::__function::__policy_invoker&)>::__call_impl[abi:se190107])::$_1, bool (std::shared_ptr&)>>(std::__function::__policy_storage const*, std::shared_ptr&) @ 0x0000000015f9837e 21. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000165d6fc3 22. /build/src/Storages/StorageReplicatedMergeTree.cpp:3872: DB::StorageReplicatedMergeTree::processQueueEntry(std::shared_ptr) @ 0x0000000015efc18a 23. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001624c1b2 24. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000162f9c70 25. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x00000000162fa55a 26. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc6653 27. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000000fccc4c3 28. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc3d92 29. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fcca080 30. ? @ 0x00007fbc6213eac3 31. ? @ 0x00007fbc621d0850 (version 25.3.6.10636.altinitytest (altinity build)) 2025.07.28 11:58:18.157559 [ 3974 ] {} test_13.rmt2 (7f9b740d-015c-470e-8cc6-8ba33be0dc63): auto DB::StorageReplicatedMergeTree::processQueueEntry(ReplicatedMergeTreeQueue::SelectedEntryPtr)::(anonymous class)::operator()(LogEntryPtr &) const: Code: 86. DB::HTTPException: Received error from remote server http://146b4357c08d:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Ftest%2F01165%2Ftest_13%2Frmt%2Freplicas%2F1&part=20250728_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.6.10636.altinitytest (altinity build)) '. (RECEIVED_ERROR_FROM_REMOTE_IO_SERVER), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.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 const&, int&&, String const&, unsigned long&&, String const&) @ 0x000000000feda8d9 4. /build/src/IO/HTTPCommon.cpp:104: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x000000000feda6e2 5. /build/src/IO/HTTPCommon.cpp:93: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x000000000feda537 6. /build/src/IO/ReadWriteBufferFromHTTP.cpp:277: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x000000001184a4c4 7. /build/src/IO/ReadWriteBufferFromHTTP.cpp:285: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x000000001184a615 8. /build/src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x000000001184ae59 9. /build/src/IO/ReadWriteBufferFromHTTP.cpp:472: void std::__function::__policy_invoker::__call_impl[abi:se190107]>(std::__function::__policy_storage const*) @ 0x000000001184cedd 10. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001184858b 11. /build/src/IO/ReadWriteBufferFromHTTP.cpp:465: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x000000001184bf0b 12. /build/src/IO/ReadBuffer.h:60: DB::ReadBuffer::next() @ 0x000000000a148c7b 13. /build/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) @ 0x0000000011849fb2 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]>&)>&, 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&) @ 0x0000000011841980 15. /build/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) @ 0x000000001621208e 16. /build/src/Storages/StorageReplicatedMergeTree.cpp:5228: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl[abi:se190107] const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000015f9a5fe 17. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000015ed8bfd 18. /build/src/Storages/StorageReplicatedMergeTree.cpp:2514: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x0000000015ec9aab 19. /build/src/Storages/StorageReplicatedMergeTree.cpp:2349: DB::StorageReplicatedMergeTree::executeLogEntry(DB::ReplicatedMergeTreeLogEntry&) @ 0x0000000015eba91b 20. /build/src/Storages/StorageReplicatedMergeTree.cpp:3876: bool std::__function::__policy_invoker&)>::__call_impl[abi:se190107])::$_1, bool (std::shared_ptr&)>>(std::__function::__policy_storage const*, std::shared_ptr&) @ 0x0000000015f9837e 21. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000165d6fc3 22. /build/src/Storages/StorageReplicatedMergeTree.cpp:3872: DB::StorageReplicatedMergeTree::processQueueEntry(std::shared_ptr) @ 0x0000000015efc18a 23. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001624c1b2 24. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000162f9c70 25. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x00000000162fa55a 26. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc6653 27. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000000fccc4c3 28. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc3d92 29. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fcca080 30. ? @ 0x00007fbc6213eac3 31. ? @ 0x00007fbc621d0850 (version 25.3.6.10636.altinitytest (altinity build)) 2025.07.28 11:58:18.279390 [ 17203 ] {aa1dfd51-18da-4596-8b1e-602d26ae9729} executeQuery: Code: 446. DB::Exception: Hyperscan functions are disabled, because setting 'allow_hyperscan' is set to 0. (FUNCTION_NOT_ALLOWED) (version 25.3.6.10636.altinitytest (altinity build)) (from [::1]:59764) (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. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000000a074fcb 4. /build/src/Functions/MultiMatchAnyImpl.h:89: DB::FunctionsMultiStringSearch>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000014298d1d 5. /build/src/Functions/IFunction.h:437: DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000a069f2a 6. /build/src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000012d9965a 7. /build/src/Functions/IFunction.cpp:351: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d93b02 8. /build/src/Functions/IFunction.cpp:420: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d95059 9. /build/src/Functions/IFunction.cpp:498: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d95c72 10. /build/src/Interpreters/ActionsDAG.cpp:812: DB::ActionsDAG::evaluatePartialResult(std::unordered_map, std::equal_to, std::allocator>>&, std::vector> const&, unsigned long, bool) @ 0x0000000013fa38cc 11. /build/src/Interpreters/ActionsDAG.cpp:892: DB::ActionsDAG::updateHeader(DB::Block const&) const @ 0x0000000013fa29a8 12. /build/src/Processors/Transforms/ExpressionTransform.cpp:10: DB::ExpressionTransform::transformHeader(DB::Block const&, DB::ActionsDAG const&) @ 0x0000000016c0afd2 13. /build/src/Processors/QueryPlan/ExpressionStep.cpp:38: DB::ExpressionStep::ExpressionStep(DB::Block const&, DB::ActionsDAG) @ 0x0000000016db8ad1 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107](DB::Block const&, DB::ActionsDAG&&) @ 0x00000000131ee01a 15. /build/src/Planner/Planner.cpp:392: DB::(anonymous namespace)::addExpressionStep(DB::QueryPlan&, std::shared_ptr&, String const&, std::unordered_set, std::hash>, std::equal_to>, std::allocator>>&) @ 0x000000001498191d 16. /build/src/Planner/Planner.cpp:1648: DB::Planner::buildPlanForQueryNode() @ 0x000000001497b7aa 17. /build/src/Planner/Planner.cpp:1308: DB::Planner::buildQueryPlanIfNeeded() @ 0x000000001497685c 18. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:255: DB::InterpreterSelectQueryAnalyzer::getQueryPlan() @ 0x000000001497476d 19. /build/src/Interpreters/executeQuery.cpp:1405: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88806 20. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 21. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 22. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 23. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 24. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 25. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 26. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 27. ? @ 0x00007fbc6213eac3 28. ? @ 0x00007fbc621d0850 2025.07.28 11:58:18.283933 [ 17203 ] {} 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. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000000a074fcb 4. /build/src/Functions/MultiMatchAnyImpl.h:89: DB::FunctionsMultiStringSearch>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000014298d1d 5. /build/src/Functions/IFunction.h:437: DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000a069f2a 6. /build/src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000012d9965a 7. /build/src/Functions/IFunction.cpp:351: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d93b02 8. /build/src/Functions/IFunction.cpp:420: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d95059 9. /build/src/Functions/IFunction.cpp:498: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d95c72 10. /build/src/Interpreters/ActionsDAG.cpp:812: DB::ActionsDAG::evaluatePartialResult(std::unordered_map, std::equal_to, std::allocator>>&, std::vector> const&, unsigned long, bool) @ 0x0000000013fa38cc 11. /build/src/Interpreters/ActionsDAG.cpp:892: DB::ActionsDAG::updateHeader(DB::Block const&) const @ 0x0000000013fa29a8 12. /build/src/Processors/Transforms/ExpressionTransform.cpp:10: DB::ExpressionTransform::transformHeader(DB::Block const&, DB::ActionsDAG const&) @ 0x0000000016c0afd2 13. /build/src/Processors/QueryPlan/ExpressionStep.cpp:38: DB::ExpressionStep::ExpressionStep(DB::Block const&, DB::ActionsDAG) @ 0x0000000016db8ad1 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107](DB::Block const&, DB::ActionsDAG&&) @ 0x00000000131ee01a 15. /build/src/Planner/Planner.cpp:392: DB::(anonymous namespace)::addExpressionStep(DB::QueryPlan&, std::shared_ptr&, String const&, std::unordered_set, std::hash>, std::equal_to>, std::allocator>>&) @ 0x000000001498191d 16. /build/src/Planner/Planner.cpp:1648: DB::Planner::buildPlanForQueryNode() @ 0x000000001497b7aa 17. /build/src/Planner/Planner.cpp:1308: DB::Planner::buildQueryPlanIfNeeded() @ 0x000000001497685c 18. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:255: DB::InterpreterSelectQueryAnalyzer::getQueryPlan() @ 0x000000001497476d 19. /build/src/Interpreters/executeQuery.cpp:1405: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88806 20. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 21. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 22. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 23. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 24. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 25. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 26. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 27. ? @ 0x00007fbc6213eac3 28. ? @ 0x00007fbc621d0850 2025.07.28 11:58:18.361580 [ 17203 ] {76d8c7cd-6542-4704-a9a8-abcde4b95684} executeQuery: Code: 446. DB::Exception: Hyperscan functions are disabled, because setting 'allow_hyperscan' is set to 0. (FUNCTION_NOT_ALLOWED) (version 25.3.6.10636.altinitytest (altinity build)) (from [::1]:59764) (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. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000000a074fcb 4. /build/src/Functions/MultiMatchAnyImpl.h:211: DB::FunctionsMultiStringSearch>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000014298e19 5. /build/src/Functions/IFunction.h:437: DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000a069f2a 6. /build/src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000012d9965a 7. /build/src/Functions/IFunction.cpp:351: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d93b02 8. /build/src/Functions/IFunction.cpp:420: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d95059 9. /build/src/Functions/IFunction.cpp:498: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d95c72 10. /build/src/Interpreters/ActionsDAG.cpp:812: DB::ActionsDAG::evaluatePartialResult(std::unordered_map, std::equal_to, std::allocator>>&, std::vector> const&, unsigned long, bool) @ 0x0000000013fa38cc 11. /build/src/Interpreters/ActionsDAG.cpp:892: DB::ActionsDAG::updateHeader(DB::Block const&) const @ 0x0000000013fa29a8 12. /build/src/Processors/Transforms/ExpressionTransform.cpp:10: DB::ExpressionTransform::transformHeader(DB::Block const&, DB::ActionsDAG const&) @ 0x0000000016c0afd2 13. /build/src/Processors/QueryPlan/ExpressionStep.cpp:38: DB::ExpressionStep::ExpressionStep(DB::Block const&, DB::ActionsDAG) @ 0x0000000016db8ad1 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107](DB::Block const&, DB::ActionsDAG&&) @ 0x00000000131ee01a 15. /build/src/Planner/Planner.cpp:392: DB::(anonymous namespace)::addExpressionStep(DB::QueryPlan&, std::shared_ptr&, String const&, std::unordered_set, std::hash>, std::equal_to>, std::allocator>>&) @ 0x000000001498191d 16. /build/src/Planner/Planner.cpp:1648: DB::Planner::buildPlanForQueryNode() @ 0x000000001497b7aa 17. /build/src/Planner/Planner.cpp:1308: DB::Planner::buildQueryPlanIfNeeded() @ 0x000000001497685c 18. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:255: DB::InterpreterSelectQueryAnalyzer::getQueryPlan() @ 0x000000001497476d 19. /build/src/Interpreters/executeQuery.cpp:1405: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88806 20. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 21. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 22. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 23. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 24. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 25. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 26. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 27. ? @ 0x00007fbc6213eac3 28. ? @ 0x00007fbc621d0850 2025.07.28 11:58:18.366120 [ 17203 ] {} 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. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000000a074fcb 4. /build/src/Functions/MultiMatchAnyImpl.h:211: DB::FunctionsMultiStringSearch>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000014298e19 5. /build/src/Functions/IFunction.h:437: DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000a069f2a 6. /build/src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000012d9965a 7. /build/src/Functions/IFunction.cpp:351: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d93b02 8. /build/src/Functions/IFunction.cpp:420: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d95059 9. /build/src/Functions/IFunction.cpp:498: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d95c72 10. /build/src/Interpreters/ActionsDAG.cpp:812: DB::ActionsDAG::evaluatePartialResult(std::unordered_map, std::equal_to, std::allocator>>&, std::vector> const&, unsigned long, bool) @ 0x0000000013fa38cc 11. /build/src/Interpreters/ActionsDAG.cpp:892: DB::ActionsDAG::updateHeader(DB::Block const&) const @ 0x0000000013fa29a8 12. /build/src/Processors/Transforms/ExpressionTransform.cpp:10: DB::ExpressionTransform::transformHeader(DB::Block const&, DB::ActionsDAG const&) @ 0x0000000016c0afd2 13. /build/src/Processors/QueryPlan/ExpressionStep.cpp:38: DB::ExpressionStep::ExpressionStep(DB::Block const&, DB::ActionsDAG) @ 0x0000000016db8ad1 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107](DB::Block const&, DB::ActionsDAG&&) @ 0x00000000131ee01a 15. /build/src/Planner/Planner.cpp:392: DB::(anonymous namespace)::addExpressionStep(DB::QueryPlan&, std::shared_ptr&, String const&, std::unordered_set, std::hash>, std::equal_to>, std::allocator>>&) @ 0x000000001498191d 16. /build/src/Planner/Planner.cpp:1648: DB::Planner::buildPlanForQueryNode() @ 0x000000001497b7aa 17. /build/src/Planner/Planner.cpp:1308: DB::Planner::buildQueryPlanIfNeeded() @ 0x000000001497685c 18. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:255: DB::InterpreterSelectQueryAnalyzer::getQueryPlan() @ 0x000000001497476d 19. /build/src/Interpreters/executeQuery.cpp:1405: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88806 20. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 21. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 22. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 23. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 24. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 25. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 26. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 27. ? @ 0x00007fbc6213eac3 28. ? @ 0x00007fbc621d0850 2025.07.28 11:58:18.460494 [ 17203 ] {8c07c076-816b-429f-b4e0-52b7a1915e43} executeQuery: Code: 446. DB::Exception: Hyperscan functions are disabled, because setting 'allow_hyperscan' is set to 0. (FUNCTION_NOT_ALLOWED) (version 25.3.6.10636.altinitytest (altinity build)) (from [::1]:59764) (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. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000000a074fcb 4. /build/src/Functions/MultiMatchAllIndicesImpl.h:75: DB::FunctionsMultiStringSearch>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000d91d2d5 5. /build/src/Functions/IFunction.h:437: DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000a069f2a 6. /build/src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000012d9965a 7. /build/src/Functions/IFunction.cpp:351: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d93b02 8. /build/src/Functions/IFunction.cpp:420: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d95059 9. /build/src/Functions/IFunction.cpp:498: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d95c72 10. /build/src/Interpreters/ActionsDAG.cpp:812: DB::ActionsDAG::evaluatePartialResult(std::unordered_map, std::equal_to, std::allocator>>&, std::vector> const&, unsigned long, bool) @ 0x0000000013fa38cc 11. /build/src/Interpreters/ActionsDAG.cpp:892: DB::ActionsDAG::updateHeader(DB::Block const&) const @ 0x0000000013fa29a8 12. /build/src/Processors/Transforms/ExpressionTransform.cpp:10: DB::ExpressionTransform::transformHeader(DB::Block const&, DB::ActionsDAG const&) @ 0x0000000016c0afd2 13. /build/src/Processors/QueryPlan/ExpressionStep.cpp:38: DB::ExpressionStep::ExpressionStep(DB::Block const&, DB::ActionsDAG) @ 0x0000000016db8ad1 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107](DB::Block const&, DB::ActionsDAG&&) @ 0x00000000131ee01a 15. /build/src/Planner/Planner.cpp:392: DB::(anonymous namespace)::addExpressionStep(DB::QueryPlan&, std::shared_ptr&, String const&, std::unordered_set, std::hash>, std::equal_to>, std::allocator>>&) @ 0x000000001498191d 16. /build/src/Planner/Planner.cpp:1648: DB::Planner::buildPlanForQueryNode() @ 0x000000001497b7aa 17. /build/src/Planner/Planner.cpp:1308: DB::Planner::buildQueryPlanIfNeeded() @ 0x000000001497685c 18. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:255: DB::InterpreterSelectQueryAnalyzer::getQueryPlan() @ 0x000000001497476d 19. /build/src/Interpreters/executeQuery.cpp:1405: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88806 20. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 21. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 22. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 23. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 24. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 25. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 26. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 27. ? @ 0x00007fbc6213eac3 28. ? @ 0x00007fbc621d0850 2025.07.28 11:58:18.473558 [ 17203 ] {} 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. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000000a074fcb 4. /build/src/Functions/MultiMatchAllIndicesImpl.h:75: DB::FunctionsMultiStringSearch>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000d91d2d5 5. /build/src/Functions/IFunction.h:437: DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000a069f2a 6. /build/src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000012d9965a 7. /build/src/Functions/IFunction.cpp:351: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d93b02 8. /build/src/Functions/IFunction.cpp:420: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d95059 9. /build/src/Functions/IFunction.cpp:498: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d95c72 10. /build/src/Interpreters/ActionsDAG.cpp:812: DB::ActionsDAG::evaluatePartialResult(std::unordered_map, std::equal_to, std::allocator>>&, std::vector> const&, unsigned long, bool) @ 0x0000000013fa38cc 11. /build/src/Interpreters/ActionsDAG.cpp:892: DB::ActionsDAG::updateHeader(DB::Block const&) const @ 0x0000000013fa29a8 12. /build/src/Processors/Transforms/ExpressionTransform.cpp:10: DB::ExpressionTransform::transformHeader(DB::Block const&, DB::ActionsDAG const&) @ 0x0000000016c0afd2 13. /build/src/Processors/QueryPlan/ExpressionStep.cpp:38: DB::ExpressionStep::ExpressionStep(DB::Block const&, DB::ActionsDAG) @ 0x0000000016db8ad1 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107](DB::Block const&, DB::ActionsDAG&&) @ 0x00000000131ee01a 15. /build/src/Planner/Planner.cpp:392: DB::(anonymous namespace)::addExpressionStep(DB::QueryPlan&, std::shared_ptr&, String const&, std::unordered_set, std::hash>, std::equal_to>, std::allocator>>&) @ 0x000000001498191d 16. /build/src/Planner/Planner.cpp:1648: DB::Planner::buildPlanForQueryNode() @ 0x000000001497b7aa 17. /build/src/Planner/Planner.cpp:1308: DB::Planner::buildQueryPlanIfNeeded() @ 0x000000001497685c 18. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:255: DB::InterpreterSelectQueryAnalyzer::getQueryPlan() @ 0x000000001497476d 19. /build/src/Interpreters/executeQuery.cpp:1405: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88806 20. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 21. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 22. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 23. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 24. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 25. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 26. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 27. ? @ 0x00007fbc6213eac3 28. ? @ 0x00007fbc621d0850 2025.07.28 11:58:18.620632 [ 17203 ] {7707212a-1243-4234-998f-32312cef20b1} executeQuery: Code: 446. DB::Exception: Hyperscan functions are disabled, because setting 'allow_hyperscan' is set to 0. (FUNCTION_NOT_ALLOWED) (version 25.3.6.10636.altinitytest (altinity build)) (from [::1]:59764) (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. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000000a074fcb 4. /build/src/Functions/MultiMatchAllIndicesImpl.h:186: DB::FunctionsMultiStringSearch>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000d91d3d5 5. /build/src/Functions/IFunction.h:437: DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000a069f2a 6. /build/src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000012d9965a 7. /build/src/Functions/IFunction.cpp:351: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d93b02 8. /build/src/Functions/IFunction.cpp:420: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d95059 9. /build/src/Functions/IFunction.cpp:498: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d95c72 10. /build/src/Interpreters/ActionsDAG.cpp:812: DB::ActionsDAG::evaluatePartialResult(std::unordered_map, std::equal_to, std::allocator>>&, std::vector> const&, unsigned long, bool) @ 0x0000000013fa38cc 11. /build/src/Interpreters/ActionsDAG.cpp:892: DB::ActionsDAG::updateHeader(DB::Block const&) const @ 0x0000000013fa29a8 12. /build/src/Processors/Transforms/ExpressionTransform.cpp:10: DB::ExpressionTransform::transformHeader(DB::Block const&, DB::ActionsDAG const&) @ 0x0000000016c0afd2 13. /build/src/Processors/QueryPlan/ExpressionStep.cpp:38: DB::ExpressionStep::ExpressionStep(DB::Block const&, DB::ActionsDAG) @ 0x0000000016db8ad1 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107](DB::Block const&, DB::ActionsDAG&&) @ 0x00000000131ee01a 15. /build/src/Planner/Planner.cpp:392: DB::(anonymous namespace)::addExpressionStep(DB::QueryPlan&, std::shared_ptr&, String const&, std::unordered_set, std::hash>, std::equal_to>, std::allocator>>&) @ 0x000000001498191d 16. /build/src/Planner/Planner.cpp:1648: DB::Planner::buildPlanForQueryNode() @ 0x000000001497b7aa 17. /build/src/Planner/Planner.cpp:1308: DB::Planner::buildQueryPlanIfNeeded() @ 0x000000001497685c 18. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:255: DB::InterpreterSelectQueryAnalyzer::getQueryPlan() @ 0x000000001497476d 19. /build/src/Interpreters/executeQuery.cpp:1405: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88806 20. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 21. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 22. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 23. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 24. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 25. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 26. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 27. ? @ 0x00007fbc6213eac3 28. ? @ 0x00007fbc621d0850 2025.07.28 11:58:18.624348 [ 17203 ] {} 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. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000000a074fcb 4. /build/src/Functions/MultiMatchAllIndicesImpl.h:186: DB::FunctionsMultiStringSearch>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000d91d3d5 5. /build/src/Functions/IFunction.h:437: DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000a069f2a 6. /build/src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000012d9965a 7. /build/src/Functions/IFunction.cpp:351: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d93b02 8. /build/src/Functions/IFunction.cpp:420: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d95059 9. /build/src/Functions/IFunction.cpp:498: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d95c72 10. /build/src/Interpreters/ActionsDAG.cpp:812: DB::ActionsDAG::evaluatePartialResult(std::unordered_map, std::equal_to, std::allocator>>&, std::vector> const&, unsigned long, bool) @ 0x0000000013fa38cc 11. /build/src/Interpreters/ActionsDAG.cpp:892: DB::ActionsDAG::updateHeader(DB::Block const&) const @ 0x0000000013fa29a8 12. /build/src/Processors/Transforms/ExpressionTransform.cpp:10: DB::ExpressionTransform::transformHeader(DB::Block const&, DB::ActionsDAG const&) @ 0x0000000016c0afd2 13. /build/src/Processors/QueryPlan/ExpressionStep.cpp:38: DB::ExpressionStep::ExpressionStep(DB::Block const&, DB::ActionsDAG) @ 0x0000000016db8ad1 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107](DB::Block const&, DB::ActionsDAG&&) @ 0x00000000131ee01a 15. /build/src/Planner/Planner.cpp:392: DB::(anonymous namespace)::addExpressionStep(DB::QueryPlan&, std::shared_ptr&, String const&, std::unordered_set, std::hash>, std::equal_to>, std::allocator>>&) @ 0x000000001498191d 16. /build/src/Planner/Planner.cpp:1648: DB::Planner::buildPlanForQueryNode() @ 0x000000001497b7aa 17. /build/src/Planner/Planner.cpp:1308: DB::Planner::buildQueryPlanIfNeeded() @ 0x000000001497685c 18. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:255: DB::InterpreterSelectQueryAnalyzer::getQueryPlan() @ 0x000000001497476d 19. /build/src/Interpreters/executeQuery.cpp:1405: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88806 20. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 21. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 22. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 23. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 24. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 25. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 26. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 27. ? @ 0x00007fbc6213eac3 28. ? @ 0x00007fbc621d0850 2025.07.28 11:58:18.644472 [ 3971 ] {} test_13.rmt2 (7f9b740d-015c-470e-8cc6-8ba33be0dc63): auto DB::StorageReplicatedMergeTree::processQueueEntry(ReplicatedMergeTreeQueue::SelectedEntryPtr)::(anonymous class)::operator()(LogEntryPtr &) const: Code: 86. DB::HTTPException: Received error from remote server http://146b4357c08d:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Ftest%2F01165%2Ftest_13%2Frmt%2Freplicas%2F1&part=20250728_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.6.10636.altinitytest (altinity build)) '. (RECEIVED_ERROR_FROM_REMOTE_IO_SERVER), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.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 const&, int&&, String const&, unsigned long&&, String const&) @ 0x000000000feda8d9 4. /build/src/IO/HTTPCommon.cpp:104: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x000000000feda6e2 5. /build/src/IO/HTTPCommon.cpp:93: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x000000000feda537 6. /build/src/IO/ReadWriteBufferFromHTTP.cpp:277: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x000000001184a4c4 7. /build/src/IO/ReadWriteBufferFromHTTP.cpp:285: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x000000001184a615 8. /build/src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x000000001184ae59 9. /build/src/IO/ReadWriteBufferFromHTTP.cpp:472: void std::__function::__policy_invoker::__call_impl[abi:se190107]>(std::__function::__policy_storage const*) @ 0x000000001184cedd 10. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001184858b 11. /build/src/IO/ReadWriteBufferFromHTTP.cpp:465: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x000000001184bf0b 12. /build/src/IO/ReadBuffer.h:60: DB::ReadBuffer::next() @ 0x000000000a148c7b 13. /build/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) @ 0x0000000011849fb2 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]>&)>&, 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&) @ 0x0000000011841980 15. /build/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) @ 0x000000001621208e 16. /build/src/Storages/StorageReplicatedMergeTree.cpp:5228: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl[abi:se190107] const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000015f9a5fe 17. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000015ed8bfd 18. /build/src/Storages/StorageReplicatedMergeTree.cpp:2514: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x0000000015ec9aab 19. /build/src/Storages/StorageReplicatedMergeTree.cpp:2349: DB::StorageReplicatedMergeTree::executeLogEntry(DB::ReplicatedMergeTreeLogEntry&) @ 0x0000000015eba91b 20. /build/src/Storages/StorageReplicatedMergeTree.cpp:3876: bool std::__function::__policy_invoker&)>::__call_impl[abi:se190107])::$_1, bool (std::shared_ptr&)>>(std::__function::__policy_storage const*, std::shared_ptr&) @ 0x0000000015f9837e 21. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000165d6fc3 22. /build/src/Storages/StorageReplicatedMergeTree.cpp:3872: DB::StorageReplicatedMergeTree::processQueueEntry(std::shared_ptr) @ 0x0000000015efc18a 23. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001624c1b2 24. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000162f9c70 25. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x00000000162fa55a 26. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc6653 27. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000000fccc4c3 28. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc3d92 29. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fcca080 30. ? @ 0x00007fbc6213eac3 31. ? @ 0x00007fbc621d0850 (version 25.3.6.10636.altinitytest (altinity build)) 2025.07.28 11:58:18.724015 [ 5112 ] {f0f84795-8a72-4be7-9798-2990df96e323} executeQuery: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=846, jobs=804). (CANNOT_SCHEDULE_TASK) (version 25.3.6.10636.altinitytest (altinity build)) (from [::1]:59758) (comment: 01550_mutation_subquery.sql) (query 7, line 8) (in query: SELECT '---';), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000fccaeeb 4. /build/src/Common/ThreadPool.cpp:275: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000fccacb3 5. /build/src/Common/ThreadPool.cpp:323: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fcc4ffc 6. /build/src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000000fcc584d 7. /build/src/Common/ThreadPool.h:279: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x00000000169bf193 8. /build/src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x00000000169bf518 9. /build/src/Server/TCPHandler.cpp:1237: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x00000000168f1525 10. /build/src/Server/TCPHandler.cpp:678: DB::TCPHandler::runImpl() @ 0x00000000168e68e5 11. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 12. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 13. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 14. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 15. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 16. ? @ 0x00007fbc6213eac3 17. ? @ 0x00007fbc621d0850 2025.07.28 11:58:18.735798 [ 5112 ] {} TCPHandler: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=846, jobs=804). (CANNOT_SCHEDULE_TASK), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000fccaeeb 4. /build/src/Common/ThreadPool.cpp:275: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000fccacb3 5. /build/src/Common/ThreadPool.cpp:323: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fcc4ffc 6. /build/src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000000fcc584d 7. /build/src/Common/ThreadPool.h:279: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x00000000169bf193 8. /build/src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x00000000169bf518 9. /build/src/Server/TCPHandler.cpp:1237: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x00000000168f1525 10. /build/src/Server/TCPHandler.cpp:678: DB::TCPHandler::runImpl() @ 0x00000000168e68e5 11. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 12. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 13. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 14. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 15. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 16. ? @ 0x00007fbc6213eac3 17. ? @ 0x00007fbc621d0850 2025.07.28 11:58:18.865210 [ 4581 ] {d04444f0-1e77-4430-aef7-dbd0013a6ab2} executeQuery: Code: 455. DB::Exception: Creating columns of type LowCardinality(Int128) 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('{}', 'JSON(a LowCardinality(Int128))'). (SUSPICIOUS_TYPE_FOR_LOW_CARDINALITY) (version 25.3.6.10636.altinitytest (altinity build)) (from [::1]:59814) (comment: 03261_json_hints_types_check.sql) (query 4, line 5) (in query: select '{}'::JSON(a LowCardinality(Int128));), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x000000000a06b56b 4. /build/src/Interpreters/parseColumnsListForTableFunction.cpp:67: DB::validateDataType(std::shared_ptr const&, DB::DataTypeValidationSettings const&)::$_0::operator()(DB::IDataType const&) const @ 0x0000000014ccea0b 5. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000013bfdcfa 6. /build/src/Interpreters/parseColumnsListForTableFunction.cpp:173: DB::validateDataType(std::shared_ptr const&, DB::DataTypeValidationSettings const&) @ 0x0000000014ccde2d 7. /build/src/Functions/CastOverloadResolver.cpp:128: DB::CastOverloadResolverImpl::getReturnTypeImpl(std::vector> const&) const @ 0x0000000012dcd4a5 8. /build/src/Functions/IFunction.cpp:645: DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x0000000012d96b0c 9. /build/src/Functions/IFunction.cpp:585: DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x0000000012d9665b 10. /build/src/Functions/IFunction.cpp:606: DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x0000000012d96edc 11. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3544: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000014033cc9 12. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3838: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000014019a9e 13. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3980: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000014018e31 14. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:4304: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000014042fa7 15. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5605: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000014013749 16. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000140127f9 17. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000014011fce 18. /build/src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000001406ce8a 19. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000014973b42 20. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000001497268d 21. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000014974d24 22. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001492924b 23. /build/src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88641 24. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 25. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 26. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 27. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 28. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 29. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 30. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 31. ? @ 0x00007fbc6213eac3 2025.07.28 11:58:18.884064 [ 4581 ] {} TCPHandler: Code: 455. DB::Exception: Creating columns of type LowCardinality(Int128) 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('{}', 'JSON(a LowCardinality(Int128))'). (SUSPICIOUS_TYPE_FOR_LOW_CARDINALITY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x000000000a06b56b 4. /build/src/Interpreters/parseColumnsListForTableFunction.cpp:67: DB::validateDataType(std::shared_ptr const&, DB::DataTypeValidationSettings const&)::$_0::operator()(DB::IDataType const&) const @ 0x0000000014ccea0b 5. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000013bfdcfa 6. /build/src/Interpreters/parseColumnsListForTableFunction.cpp:173: DB::validateDataType(std::shared_ptr const&, DB::DataTypeValidationSettings const&) @ 0x0000000014ccde2d 7. /build/src/Functions/CastOverloadResolver.cpp:128: DB::CastOverloadResolverImpl::getReturnTypeImpl(std::vector> const&) const @ 0x0000000012dcd4a5 8. /build/src/Functions/IFunction.cpp:645: DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x0000000012d96b0c 9. /build/src/Functions/IFunction.cpp:585: DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x0000000012d9665b 10. /build/src/Functions/IFunction.cpp:606: DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x0000000012d96edc 11. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3544: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000014033cc9 12. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3838: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000014019a9e 13. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3980: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000014018e31 14. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:4304: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000014042fa7 15. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5605: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000014013749 16. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000140127f9 17. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000014011fce 18. /build/src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000001406ce8a 19. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000014973b42 20. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000001497268d 21. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000014974d24 22. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001492924b 23. /build/src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88641 24. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 25. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 26. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 27. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 28. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 29. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 30. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 31. ? @ 0x00007fbc6213eac3 2025.07.28 11:58:18.971616 [ 4581 ] {a734aa96-14e8-4361-a225-9c86358a7799} executeQuery: Code: 44. DB::Exception: Cannot create column with type 'FixedString(100000)' 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('{}', 'JSON(a FixedString(100000))'). (ILLEGAL_COLUMN) (version 25.3.6.10636.altinitytest (altinity build)) (from [::1]:59814) (comment: 03261_json_hints_types_check.sql) (query 5, line 6) (in query: select '{}'::JSON(a FixedString(100000));), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, unsigned long const&) @ 0x000000000a3d916b 4. /build/src/Interpreters/parseColumnsListForTableFunction.cpp:92: DB::validateDataType(std::shared_ptr const&, DB::DataTypeValidationSettings const&)::$_0::operator()(DB::IDataType const&) const @ 0x0000000014cce8bf 5. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000013bfdcfa 6. /build/src/Interpreters/parseColumnsListForTableFunction.cpp:173: DB::validateDataType(std::shared_ptr const&, DB::DataTypeValidationSettings const&) @ 0x0000000014ccde2d 7. /build/src/Functions/CastOverloadResolver.cpp:128: DB::CastOverloadResolverImpl::getReturnTypeImpl(std::vector> const&) const @ 0x0000000012dcd4a5 8. /build/src/Functions/IFunction.cpp:645: DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x0000000012d96b0c 9. /build/src/Functions/IFunction.cpp:585: DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x0000000012d9665b 10. /build/src/Functions/IFunction.cpp:606: DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x0000000012d96edc 11. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3544: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000014033cc9 12. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3838: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000014019a9e 13. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3980: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000014018e31 14. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:4304: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000014042fa7 15. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5605: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000014013749 16. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000140127f9 17. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000014011fce 18. /build/src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000001406ce8a 19. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000014973b42 20. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000001497268d 21. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000014974d24 22. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001492924b 23. /build/src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88641 24. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 25. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 26. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 27. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 28. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 29. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 30. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 31. ? @ 0x00007fbc6213eac3 2025.07.28 11:58:19.015052 [ 4581 ] {} TCPHandler: Code: 44. DB::Exception: Cannot create column with type 'FixedString(100000)' 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('{}', 'JSON(a FixedString(100000))'). (ILLEGAL_COLUMN), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, unsigned long const&) @ 0x000000000a3d916b 4. /build/src/Interpreters/parseColumnsListForTableFunction.cpp:92: DB::validateDataType(std::shared_ptr const&, DB::DataTypeValidationSettings const&)::$_0::operator()(DB::IDataType const&) const @ 0x0000000014cce8bf 5. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000013bfdcfa 6. /build/src/Interpreters/parseColumnsListForTableFunction.cpp:173: DB::validateDataType(std::shared_ptr const&, DB::DataTypeValidationSettings const&) @ 0x0000000014ccde2d 7. /build/src/Functions/CastOverloadResolver.cpp:128: DB::CastOverloadResolverImpl::getReturnTypeImpl(std::vector> const&) const @ 0x0000000012dcd4a5 8. /build/src/Functions/IFunction.cpp:645: DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x0000000012d96b0c 9. /build/src/Functions/IFunction.cpp:585: DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x0000000012d9665b 10. /build/src/Functions/IFunction.cpp:606: DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x0000000012d96edc 11. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3544: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000014033cc9 12. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3838: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000014019a9e 13. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3980: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000014018e31 14. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:4304: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000014042fa7 15. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5605: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000014013749 16. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000140127f9 17. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000014011fce 18. /build/src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000001406ce8a 19. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000014973b42 20. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000001497268d 21. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000014974d24 22. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001492924b 23. /build/src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88641 24. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 25. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 26. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 27. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 28. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 29. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 30. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 31. ? @ 0x00007fbc6213eac3 2025.07.28 11:58:19.112740 [ 4581 ] {25204ab6-21e2-4c5e-9398-f31baf9626b5} executeQuery: Code: 44. DB::Exception: Cannot create column with type 'Variant(Int32)' because Variant type is not allowed. Set setting enable_variant_type = 1 in order to allow it: In scope SELECT CAST('{}', 'JSON(a Variant(Int32))'). (ILLEGAL_COLUMN) (version 25.3.6.10636.altinitytest (altinity build)) (from [::1]:59814) (comment: 03261_json_hints_types_check.sql) (query 6, line 7) (in query: select '{}'::JSON(a Variant(Int32));), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x000000000a06b56b 4. /build/src/Interpreters/parseColumnsListForTableFunction.cpp:105: DB::validateDataType(std::shared_ptr const&, DB::DataTypeValidationSettings const&)::$_0::operator()(DB::IDataType const&) const @ 0x0000000014cce784 5. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000013bfdcfa 6. /build/src/Interpreters/parseColumnsListForTableFunction.cpp:173: DB::validateDataType(std::shared_ptr const&, DB::DataTypeValidationSettings const&) @ 0x0000000014ccde2d 7. /build/src/Functions/CastOverloadResolver.cpp:128: DB::CastOverloadResolverImpl::getReturnTypeImpl(std::vector> const&) const @ 0x0000000012dcd4a5 8. /build/src/Functions/IFunction.cpp:645: DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x0000000012d96b0c 9. /build/src/Functions/IFunction.cpp:585: DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x0000000012d9665b 10. /build/src/Functions/IFunction.cpp:606: DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x0000000012d96edc 11. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3544: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000014033cc9 12. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3838: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000014019a9e 13. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3980: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000014018e31 14. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:4304: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000014042fa7 15. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5605: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000014013749 16. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000140127f9 17. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000014011fce 18. /build/src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000001406ce8a 19. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000014973b42 20. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000001497268d 21. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000014974d24 22. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001492924b 23. /build/src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88641 24. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 25. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 26. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 27. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 28. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 29. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 30. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 31. ? @ 0x00007fbc6213eac3 2025.07.28 11:58:19.139178 [ 4581 ] {} TCPHandler: Code: 44. DB::Exception: Cannot create column with type 'Variant(Int32)' because Variant type is not allowed. Set setting enable_variant_type = 1 in order to allow it: In scope SELECT CAST('{}', 'JSON(a Variant(Int32))'). (ILLEGAL_COLUMN), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x000000000a06b56b 4. /build/src/Interpreters/parseColumnsListForTableFunction.cpp:105: DB::validateDataType(std::shared_ptr const&, DB::DataTypeValidationSettings const&)::$_0::operator()(DB::IDataType const&) const @ 0x0000000014cce784 5. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000013bfdcfa 6. /build/src/Interpreters/parseColumnsListForTableFunction.cpp:173: DB::validateDataType(std::shared_ptr const&, DB::DataTypeValidationSettings const&) @ 0x0000000014ccde2d 7. /build/src/Functions/CastOverloadResolver.cpp:128: DB::CastOverloadResolverImpl::getReturnTypeImpl(std::vector> const&) const @ 0x0000000012dcd4a5 8. /build/src/Functions/IFunction.cpp:645: DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x0000000012d96b0c 9. /build/src/Functions/IFunction.cpp:585: DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x0000000012d9665b 10. /build/src/Functions/IFunction.cpp:606: DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x0000000012d96edc 11. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3544: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000014033cc9 12. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3838: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000014019a9e 13. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3980: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000014018e31 14. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:4304: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000014042fa7 15. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5605: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000014013749 16. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000140127f9 17. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000014011fce 18. /build/src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000001406ce8a 19. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000014973b42 20. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000001497268d 21. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000014974d24 22. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001492924b 23. /build/src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88641 24. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 25. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 26. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 27. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 28. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 29. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 30. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 31. ? @ 0x00007fbc6213eac3 2025.07.28 11:58:19.240571 [ 4581 ] {a2c5a4d8-191f-4b10-ab8b-9072124c8b8f} 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('{}', 'JSON(a Object(\'json\'))'). (ILLEGAL_COLUMN) (version 25.3.6.10636.altinitytest (altinity build)) (from [::1]:59814) (comment: 03261_json_hints_types_check.sql) (query 7, line 8) (in query: select '{}'::JSON(a Object('json'));), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x000000000a06b56b 4. /build/src/Interpreters/parseColumnsListForTableFunction.cpp:79: DB::validateDataType(std::shared_ptr const&, DB::DataTypeValidationSettings const&)::$_0::operator()(DB::IDataType const&) const @ 0x0000000014cce6ec 5. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000013bfdcfa 6. /build/src/Interpreters/parseColumnsListForTableFunction.cpp:173: DB::validateDataType(std::shared_ptr const&, DB::DataTypeValidationSettings const&) @ 0x0000000014ccde2d 7. /build/src/Functions/CastOverloadResolver.cpp:128: DB::CastOverloadResolverImpl::getReturnTypeImpl(std::vector> const&) const @ 0x0000000012dcd4a5 8. /build/src/Functions/IFunction.cpp:645: DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x0000000012d96b0c 9. /build/src/Functions/IFunction.cpp:585: DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x0000000012d9665b 10. /build/src/Functions/IFunction.cpp:606: DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x0000000012d96edc 11. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3544: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000014033cc9 12. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3838: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000014019a9e 13. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3980: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000014018e31 14. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:4304: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000014042fa7 15. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5605: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000014013749 16. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000140127f9 17. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000014011fce 18. /build/src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000001406ce8a 19. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000014973b42 20. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000001497268d 21. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000014974d24 22. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001492924b 23. /build/src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88641 24. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 25. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 26. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 27. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 28. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 29. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 30. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 31. ? @ 0x00007fbc6213eac3 2025.07.28 11:58:19.278093 [ 4581 ] {} 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('{}', 'JSON(a Object(\'json\'))'). (ILLEGAL_COLUMN), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x000000000a06b56b 4. /build/src/Interpreters/parseColumnsListForTableFunction.cpp:79: DB::validateDataType(std::shared_ptr const&, DB::DataTypeValidationSettings const&)::$_0::operator()(DB::IDataType const&) const @ 0x0000000014cce6ec 5. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000013bfdcfa 6. /build/src/Interpreters/parseColumnsListForTableFunction.cpp:173: DB::validateDataType(std::shared_ptr const&, DB::DataTypeValidationSettings const&) @ 0x0000000014ccde2d 7. /build/src/Functions/CastOverloadResolver.cpp:128: DB::CastOverloadResolverImpl::getReturnTypeImpl(std::vector> const&) const @ 0x0000000012dcd4a5 8. /build/src/Functions/IFunction.cpp:645: DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x0000000012d96b0c 9. /build/src/Functions/IFunction.cpp:585: DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x0000000012d9665b 10. /build/src/Functions/IFunction.cpp:606: DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x0000000012d96edc 11. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3544: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000014033cc9 12. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3838: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000014019a9e 13. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3980: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000014018e31 14. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:4304: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000014042fa7 15. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5605: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000014013749 16. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000140127f9 17. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000014011fce 18. /build/src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000001406ce8a 19. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000014973b42 20. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000001497268d 21. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000014974d24 22. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001492924b 23. /build/src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88641 24. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 25. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 26. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 27. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 28. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 29. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 30. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 31. ? @ 0x00007fbc6213eac3 2025.07.28 11:58:19.429948 [ 17203 ] {f9780378-019e-4830-b077-4308e6c56c65} executeQuery: Code: 452. DB::Exception: Setting allow_experimental_object_type should not be changed. (SETTING_CONSTRAINT_VIOLATION) (version 25.3.6.10636.altinitytest (altinity build)) (from [::1]:59838) (comment: 03270_object_to_json_alter_compact_merge_tree.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. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x000000000c25bc4b 4. /build/src/Access/SettingsConstraints.cpp:343: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000138596e3 5. /build/src/Access/SettingsConstraints.cpp:300: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000013858faf 6. /build/src/Access/SettingsConstraints.cpp:194: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges const&, DB::SettingSource) const @ 0x00000000138591b3 7. /build/src/Interpreters/Context.cpp:2722: DB::Context::checkSettingsConstraints(DB::SettingsChanges const&, DB::SettingSource) @ 0x0000000014436509 8. /build/src/Interpreters/InterpreterSetQuery.cpp:28: DB::InterpreterSetQuery::execute() @ 0x00000000149e240a 9. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88dc9 10. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 11. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 12. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 13. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 14. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 16. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 17. ? @ 0x00007fbc6213eac3 18. ? @ 0x00007fbc621d0850 2025.07.28 11:58:19.444371 [ 17203 ] {} 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. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x000000000c25bc4b 4. /build/src/Access/SettingsConstraints.cpp:343: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000138596e3 5. /build/src/Access/SettingsConstraints.cpp:300: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000013858faf 6. /build/src/Access/SettingsConstraints.cpp:194: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges const&, DB::SettingSource) const @ 0x00000000138591b3 7. /build/src/Interpreters/Context.cpp:2722: DB::Context::checkSettingsConstraints(DB::SettingsChanges const&, DB::SettingSource) @ 0x0000000014436509 8. /build/src/Interpreters/InterpreterSetQuery.cpp:28: DB::InterpreterSetQuery::execute() @ 0x00000000149e240a 9. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88dc9 10. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 11. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 12. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 13. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 14. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 16. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 17. ? @ 0x00007fbc6213eac3 18. ? @ 0x00007fbc621d0850 2025.07.28 11:58:19.559177 [ 3960 ] {} test_13.rmt2 (7f9b740d-015c-470e-8cc6-8ba33be0dc63): auto DB::StorageReplicatedMergeTree::processQueueEntry(ReplicatedMergeTreeQueue::SelectedEntryPtr)::(anonymous class)::operator()(LogEntryPtr &) const: Code: 86. DB::HTTPException: Received error from remote server http://146b4357c08d:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Ftest%2F01165%2Ftest_13%2Frmt%2Freplicas%2F1&part=20250728_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.6.10636.altinitytest (altinity build)) '. (RECEIVED_ERROR_FROM_REMOTE_IO_SERVER), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.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 const&, int&&, String const&, unsigned long&&, String const&) @ 0x000000000feda8d9 4. /build/src/IO/HTTPCommon.cpp:104: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x000000000feda6e2 5. /build/src/IO/HTTPCommon.cpp:93: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x000000000feda537 6. /build/src/IO/ReadWriteBufferFromHTTP.cpp:277: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x000000001184a4c4 7. /build/src/IO/ReadWriteBufferFromHTTP.cpp:285: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x000000001184a615 8. /build/src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x000000001184ae59 9. /build/src/IO/ReadWriteBufferFromHTTP.cpp:472: void std::__function::__policy_invoker::__call_impl[abi:se190107]>(std::__function::__policy_storage const*) @ 0x000000001184cedd 10. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001184858b 11. /build/src/IO/ReadWriteBufferFromHTTP.cpp:465: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x000000001184bf0b 12. /build/src/IO/ReadBuffer.h:60: DB::ReadBuffer::next() @ 0x000000000a148c7b 13. /build/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) @ 0x0000000011849fb2 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]>&)>&, 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&) @ 0x0000000011841980 15. /build/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) @ 0x000000001621208e 16. /build/src/Storages/StorageReplicatedMergeTree.cpp:5228: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl[abi:se190107] const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000015f9a5fe 17. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000015ed8bfd 18. /build/src/Storages/StorageReplicatedMergeTree.cpp:2514: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x0000000015ec9aab 19. /build/src/Storages/StorageReplicatedMergeTree.cpp:2349: DB::StorageReplicatedMergeTree::executeLogEntry(DB::ReplicatedMergeTreeLogEntry&) @ 0x0000000015eba91b 20. /build/src/Storages/StorageReplicatedMergeTree.cpp:3876: bool std::__function::__policy_invoker&)>::__call_impl[abi:se190107])::$_1, bool (std::shared_ptr&)>>(std::__function::__policy_storage const*, std::shared_ptr&) @ 0x0000000015f9837e 21. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000165d6fc3 22. /build/src/Storages/StorageReplicatedMergeTree.cpp:3872: DB::StorageReplicatedMergeTree::processQueueEntry(std::shared_ptr) @ 0x0000000015efc18a 23. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001624c1b2 24. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000162f9c70 25. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x00000000162fa55a 26. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc6653 27. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000000fccc4c3 28. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc3d92 29. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fcca080 30. ? @ 0x00007fbc6213eac3 31. ? @ 0x00007fbc621d0850 (version 25.3.6.10636.altinitytest (altinity build)) 2025.07.28 11:58:20.628541 [ 3966 ] {} test_13.rmt2 (7f9b740d-015c-470e-8cc6-8ba33be0dc63): auto DB::StorageReplicatedMergeTree::processQueueEntry(ReplicatedMergeTreeQueue::SelectedEntryPtr)::(anonymous class)::operator()(LogEntryPtr &) const: Code: 86. DB::HTTPException: Received error from remote server http://146b4357c08d:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Ftest%2F01165%2Ftest_13%2Frmt%2Freplicas%2F1&part=20250728_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.6.10636.altinitytest (altinity build)) '. (RECEIVED_ERROR_FROM_REMOTE_IO_SERVER), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.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 const&, int&&, String const&, unsigned long&&, String const&) @ 0x000000000feda8d9 4. /build/src/IO/HTTPCommon.cpp:104: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x000000000feda6e2 5. /build/src/IO/HTTPCommon.cpp:93: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x000000000feda537 6. /build/src/IO/ReadWriteBufferFromHTTP.cpp:277: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x000000001184a4c4 7. /build/src/IO/ReadWriteBufferFromHTTP.cpp:285: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x000000001184a615 8. /build/src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x000000001184ae59 9. /build/src/IO/ReadWriteBufferFromHTTP.cpp:472: void std::__function::__policy_invoker::__call_impl[abi:se190107]>(std::__function::__policy_storage const*) @ 0x000000001184cedd 10. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001184858b 11. /build/src/IO/ReadWriteBufferFromHTTP.cpp:465: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x000000001184bf0b 12. /build/src/IO/ReadBuffer.h:60: DB::ReadBuffer::next() @ 0x000000000a148c7b 13. /build/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) @ 0x0000000011849fb2 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]>&)>&, 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&) @ 0x0000000011841980 15. /build/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) @ 0x000000001621208e 16. /build/src/Storages/StorageReplicatedMergeTree.cpp:5228: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl[abi:se190107] const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000015f9a5fe 17. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000015ed8bfd 18. /build/src/Storages/StorageReplicatedMergeTree.cpp:2514: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x0000000015ec9aab 19. /build/src/Storages/StorageReplicatedMergeTree.cpp:2349: DB::StorageReplicatedMergeTree::executeLogEntry(DB::ReplicatedMergeTreeLogEntry&) @ 0x0000000015eba91b 20. /build/src/Storages/StorageReplicatedMergeTree.cpp:3876: bool std::__function::__policy_invoker&)>::__call_impl[abi:se190107])::$_1, bool (std::shared_ptr&)>>(std::__function::__policy_storage const*, std::shared_ptr&) @ 0x0000000015f9837e 21. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000165d6fc3 22. /build/src/Storages/StorageReplicatedMergeTree.cpp:3872: DB::StorageReplicatedMergeTree::processQueueEntry(std::shared_ptr) @ 0x0000000015efc18a 23. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001624c1b2 24. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000162f9c70 25. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x00000000162fa55a 26. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc6653 27. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000000fccc4c3 28. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc3d92 29. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fcca080 30. ? @ 0x00007fbc6213eac3 31. ? @ 0x00007fbc621d0850 (version 25.3.6.10636.altinitytest (altinity build)) 2025.07.28 11:58:21.522297 [ 3972 ] {} test_13.rmt2 (7f9b740d-015c-470e-8cc6-8ba33be0dc63): auto DB::StorageReplicatedMergeTree::processQueueEntry(ReplicatedMergeTreeQueue::SelectedEntryPtr)::(anonymous class)::operator()(LogEntryPtr &) const: Code: 86. DB::HTTPException: Received error from remote server http://146b4357c08d:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Ftest%2F01165%2Ftest_13%2Frmt%2Freplicas%2F1&part=20250728_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.6.10636.altinitytest (altinity build)) '. (RECEIVED_ERROR_FROM_REMOTE_IO_SERVER), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.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 const&, int&&, String const&, unsigned long&&, String const&) @ 0x000000000feda8d9 4. /build/src/IO/HTTPCommon.cpp:104: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x000000000feda6e2 5. /build/src/IO/HTTPCommon.cpp:93: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x000000000feda537 6. /build/src/IO/ReadWriteBufferFromHTTP.cpp:277: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x000000001184a4c4 7. /build/src/IO/ReadWriteBufferFromHTTP.cpp:285: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x000000001184a615 8. /build/src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x000000001184ae59 9. /build/src/IO/ReadWriteBufferFromHTTP.cpp:472: void std::__function::__policy_invoker::__call_impl[abi:se190107]>(std::__function::__policy_storage const*) @ 0x000000001184cedd 10. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001184858b 11. /build/src/IO/ReadWriteBufferFromHTTP.cpp:465: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x000000001184bf0b 12. /build/src/IO/ReadBuffer.h:60: DB::ReadBuffer::next() @ 0x000000000a148c7b 13. /build/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) @ 0x0000000011849fb2 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]>&)>&, 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&) @ 0x0000000011841980 15. /build/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) @ 0x000000001621208e 16. /build/src/Storages/StorageReplicatedMergeTree.cpp:5228: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl[abi:se190107] const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000015f9a5fe 17. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000015ed8bfd 18. /build/src/Storages/StorageReplicatedMergeTree.cpp:2514: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x0000000015ec9aab 19. /build/src/Storages/StorageReplicatedMergeTree.cpp:2349: DB::StorageReplicatedMergeTree::executeLogEntry(DB::ReplicatedMergeTreeLogEntry&) @ 0x0000000015eba91b 20. /build/src/Storages/StorageReplicatedMergeTree.cpp:3876: bool std::__function::__policy_invoker&)>::__call_impl[abi:se190107])::$_1, bool (std::shared_ptr&)>>(std::__function::__policy_storage const*, std::shared_ptr&) @ 0x0000000015f9837e 21. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000165d6fc3 22. /build/src/Storages/StorageReplicatedMergeTree.cpp:3872: DB::StorageReplicatedMergeTree::processQueueEntry(std::shared_ptr) @ 0x0000000015efc18a 23. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001624c1b2 24. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000162f9c70 25. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x00000000162fa55a 26. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc6653 27. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000000fccc4c3 28. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc3d92 29. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fcca080 30. ? @ 0x00007fbc6213eac3 31. ? @ 0x00007fbc621d0850 (version 25.3.6.10636.altinitytest (altinity build)) 2025.07.28 11:58:21.787619 [ 3941 ] {381129cc-eb00-436a-b221-12d159eb6193::all_19_24_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. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000000a074fcb 4. /build/src/Storages/MergeTree/MergeTask.cpp:244: DB::MergeTask::GlobalRuntimeContext::checkOperationIsNotCanceled() const @ 0x00000000162cab7a 5. /build/src/Storages/MergeTree/MergeTask.cpp:921: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::finalize() const @ 0x00000000162d761c 6. /build/src/Storages/MergeTree/MergeTask.cpp:882: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::executeImpl() const @ 0x00000000162d73b8 7. /build/src/Storages/MergeTree/MergeTask.cpp:710: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::execute() @ 0x00000000162d5ad9 8. /build/src/Storages/MergeTree/MergeTask.cpp:1485: DB::MergeTask::execute() @ 0x00000000162dbf2a 9. /build/src/Storages/MergeTree/MergePlainMergeTreeTask.cpp:57: DB::MergePlainMergeTreeTask::executeStep() @ 0x000000001666e865 10. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000162fc850 11. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x00000000162fd193 12. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc6653 13. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000000fccc4c3 14. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc3d92 15. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fcca080 16. ? @ 0x00007fbc6213eac3 17. ? @ 0x00007fbc621d0850 (version 25.3.6.10636.altinitytest (altinity build)) 2025.07.28 11:58:21.848191 [ 3946 ] {381129cc-eb00-436a-b221-12d159eb6193::all_1_18_2} 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. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000000a074fcb 4. /build/src/Storages/MergeTree/MergeTask.cpp:244: DB::MergeTask::GlobalRuntimeContext::checkOperationIsNotCanceled() const @ 0x00000000162cab7a 5. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000162eeb33 6. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000013bb1c9e 7. /build/src/Processors/Executors/ExecutionThreadContext.cpp:68: DB::ExecutionThreadContext::executeTask() @ 0x00000000169bd08f 8. /build/src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x00000000169b2105 9. /build/src/Processors/Executors/PipelineExecutor.cpp:170: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x00000000169b16a7 10. /build/src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x00000000169c081c 11. /build/src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x00000000169c0978 12. /build/src/Storages/MergeTree/MergeTask.cpp:880: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::executeImpl() const @ 0x00000000162d7282 13. /build/src/Storages/MergeTree/MergeTask.cpp:710: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::execute() @ 0x00000000162d5ad9 14. /build/src/Storages/MergeTree/MergeTask.cpp:1485: DB::MergeTask::execute() @ 0x00000000162dbf2a 15. /build/src/Storages/MergeTree/MergePlainMergeTreeTask.cpp:57: DB::MergePlainMergeTreeTask::executeStep() @ 0x000000001666e865 16. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000162fc850 17. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x00000000162fd193 18. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc6653 19. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000000fccc4c3 20. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc3d92 21. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fcca080 22. ? @ 0x00007fbc6213eac3 23. ? @ 0x00007fbc621d0850 (version 25.3.6.10636.altinitytest (altinity build)) 2025.07.28 11:58:21.882941 [ 3961 ] {} test_13.rmt2 (7f9b740d-015c-470e-8cc6-8ba33be0dc63): auto DB::StorageReplicatedMergeTree::processQueueEntry(ReplicatedMergeTreeQueue::SelectedEntryPtr)::(anonymous class)::operator()(LogEntryPtr &) const: Code: 86. DB::HTTPException: Received error from remote server http://146b4357c08d:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Ftest%2F01165%2Ftest_13%2Frmt%2Freplicas%2F1&part=20250728_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.6.10636.altinitytest (altinity build)) '. (RECEIVED_ERROR_FROM_REMOTE_IO_SERVER), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.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 const&, int&&, String const&, unsigned long&&, String const&) @ 0x000000000feda8d9 4. /build/src/IO/HTTPCommon.cpp:104: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x000000000feda6e2 5. /build/src/IO/HTTPCommon.cpp:93: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x000000000feda537 6. /build/src/IO/ReadWriteBufferFromHTTP.cpp:277: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x000000001184a4c4 7. /build/src/IO/ReadWriteBufferFromHTTP.cpp:285: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x000000001184a615 8. /build/src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x000000001184ae59 9. /build/src/IO/ReadWriteBufferFromHTTP.cpp:472: void std::__function::__policy_invoker::__call_impl[abi:se190107]>(std::__function::__policy_storage const*) @ 0x000000001184cedd 10. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001184858b 11. /build/src/IO/ReadWriteBufferFromHTTP.cpp:465: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x000000001184bf0b 12. /build/src/IO/ReadBuffer.h:60: DB::ReadBuffer::next() @ 0x000000000a148c7b 13. /build/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) @ 0x0000000011849fb2 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]>&)>&, 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&) @ 0x0000000011841980 15. /build/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) @ 0x000000001621208e 16. /build/src/Storages/StorageReplicatedMergeTree.cpp:5228: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl[abi:se190107] const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000015f9a5fe 17. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000015ed8bfd 18. /build/src/Storages/StorageReplicatedMergeTree.cpp:2514: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x0000000015ec9aab 19. /build/src/Storages/StorageReplicatedMergeTree.cpp:2349: DB::StorageReplicatedMergeTree::executeLogEntry(DB::ReplicatedMergeTreeLogEntry&) @ 0x0000000015eba91b 20. /build/src/Storages/StorageReplicatedMergeTree.cpp:3876: bool std::__function::__policy_invoker&)>::__call_impl[abi:se190107])::$_1, bool (std::shared_ptr&)>>(std::__function::__policy_storage const*, std::shared_ptr&) @ 0x0000000015f9837e 21. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000165d6fc3 22. /build/src/Storages/StorageReplicatedMergeTree.cpp:3872: DB::StorageReplicatedMergeTree::processQueueEntry(std::shared_ptr) @ 0x0000000015efc18a 23. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001624c1b2 24. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000162f9c70 25. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x00000000162fa55a 26. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc6653 27. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000000fccc4c3 28. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc3d92 29. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fcca080 30. ? @ 0x00007fbc6213eac3 31. ? @ 0x00007fbc621d0850 (version 25.3.6.10636.altinitytest (altinity build)) 2025.07.28 11:58:22.558211 [ 3974 ] {} test_13.rmt2 (7f9b740d-015c-470e-8cc6-8ba33be0dc63): auto DB::StorageReplicatedMergeTree::processQueueEntry(ReplicatedMergeTreeQueue::SelectedEntryPtr)::(anonymous class)::operator()(LogEntryPtr &) const: Code: 86. DB::HTTPException: Received error from remote server http://146b4357c08d:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Ftest%2F01165%2Ftest_13%2Frmt%2Freplicas%2F1&part=20250728_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.6.10636.altinitytest (altinity build)) '. (RECEIVED_ERROR_FROM_REMOTE_IO_SERVER), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.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 const&, int&&, String const&, unsigned long&&, String const&) @ 0x000000000feda8d9 4. /build/src/IO/HTTPCommon.cpp:104: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x000000000feda6e2 5. /build/src/IO/HTTPCommon.cpp:93: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x000000000feda537 6. /build/src/IO/ReadWriteBufferFromHTTP.cpp:277: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x000000001184a4c4 7. /build/src/IO/ReadWriteBufferFromHTTP.cpp:285: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x000000001184a615 8. /build/src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x000000001184ae59 9. /build/src/IO/ReadWriteBufferFromHTTP.cpp:472: void std::__function::__policy_invoker::__call_impl[abi:se190107]>(std::__function::__policy_storage const*) @ 0x000000001184cedd 10. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001184858b 11. /build/src/IO/ReadWriteBufferFromHTTP.cpp:465: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x000000001184bf0b 12. /build/src/IO/ReadBuffer.h:60: DB::ReadBuffer::next() @ 0x000000000a148c7b 13. /build/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) @ 0x0000000011849fb2 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]>&)>&, 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&) @ 0x0000000011841980 15. /build/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) @ 0x000000001621208e 16. /build/src/Storages/StorageReplicatedMergeTree.cpp:5228: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl[abi:se190107] const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000015f9a5fe 17. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000015ed8bfd 18. /build/src/Storages/StorageReplicatedMergeTree.cpp:2514: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x0000000015ec9aab 19. /build/src/Storages/StorageReplicatedMergeTree.cpp:2349: DB::StorageReplicatedMergeTree::executeLogEntry(DB::ReplicatedMergeTreeLogEntry&) @ 0x0000000015eba91b 20. /build/src/Storages/StorageReplicatedMergeTree.cpp:3876: bool std::__function::__policy_invoker&)>::__call_impl[abi:se190107])::$_1, bool (std::shared_ptr&)>>(std::__function::__policy_storage const*, std::shared_ptr&) @ 0x0000000015f9837e 21. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000165d6fc3 22. /build/src/Storages/StorageReplicatedMergeTree.cpp:3872: DB::StorageReplicatedMergeTree::processQueueEntry(std::shared_ptr) @ 0x0000000015efc18a 23. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001624c1b2 24. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000162f9c70 25. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x00000000162fa55a 26. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc6653 27. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000000fccc4c3 28. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc3d92 29. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fcca080 30. ? @ 0x00007fbc6213eac3 31. ? @ 0x00007fbc621d0850 (version 25.3.6.10636.altinitytest (altinity build)) 2025.07.28 11:58:23.185057 [ 3977 ] {} test_13.rmt2 (7f9b740d-015c-470e-8cc6-8ba33be0dc63): auto DB::StorageReplicatedMergeTree::processQueueEntry(ReplicatedMergeTreeQueue::SelectedEntryPtr)::(anonymous class)::operator()(LogEntryPtr &) const: Code: 86. DB::HTTPException: Received error from remote server http://146b4357c08d:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Ftest%2F01165%2Ftest_13%2Frmt%2Freplicas%2F1&part=20250728_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.6.10636.altinitytest (altinity build)) '. (RECEIVED_ERROR_FROM_REMOTE_IO_SERVER), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.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 const&, int&&, String const&, unsigned long&&, String const&) @ 0x000000000feda8d9 4. /build/src/IO/HTTPCommon.cpp:104: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x000000000feda6e2 5. /build/src/IO/HTTPCommon.cpp:93: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x000000000feda537 6. /build/src/IO/ReadWriteBufferFromHTTP.cpp:277: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x000000001184a4c4 7. /build/src/IO/ReadWriteBufferFromHTTP.cpp:285: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x000000001184a615 8. /build/src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x000000001184ae59 9. /build/src/IO/ReadWriteBufferFromHTTP.cpp:472: void std::__function::__policy_invoker::__call_impl[abi:se190107]>(std::__function::__policy_storage const*) @ 0x000000001184cedd 10. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001184858b 11. /build/src/IO/ReadWriteBufferFromHTTP.cpp:465: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x000000001184bf0b 12. /build/src/IO/ReadBuffer.h:60: DB::ReadBuffer::next() @ 0x000000000a148c7b 13. /build/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) @ 0x0000000011849fb2 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]>&)>&, 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&) @ 0x0000000011841980 15. /build/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) @ 0x000000001621208e 16. /build/src/Storages/StorageReplicatedMergeTree.cpp:5228: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl[abi:se190107] const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000015f9a5fe 17. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000015ed8bfd 18. /build/src/Storages/StorageReplicatedMergeTree.cpp:2514: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x0000000015ec9aab 19. /build/src/Storages/StorageReplicatedMergeTree.cpp:2349: DB::StorageReplicatedMergeTree::executeLogEntry(DB::ReplicatedMergeTreeLogEntry&) @ 0x0000000015eba91b 20. /build/src/Storages/StorageReplicatedMergeTree.cpp:3876: bool std::__function::__policy_invoker&)>::__call_impl[abi:se190107])::$_1, bool (std::shared_ptr&)>>(std::__function::__policy_storage const*, std::shared_ptr&) @ 0x0000000015f9837e 21. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000165d6fc3 22. /build/src/Storages/StorageReplicatedMergeTree.cpp:3872: DB::StorageReplicatedMergeTree::processQueueEntry(std::shared_ptr) @ 0x0000000015efc18a 23. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001624c1b2 24. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000162f9c70 25. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x00000000162fa55a 26. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc6653 27. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000000fccc4c3 28. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc3d92 29. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fcca080 30. ? @ 0x00007fbc6213eac3 31. ? @ 0x00007fbc621d0850 (version 25.3.6.10636.altinitytest (altinity build)) 2025.07.28 11:58:23.544499 [ 17208 ] {4adcc7a5-d959-415c-8325-327a16673ca9} executeQuery: Code: 439. DB::Exception: Cannot schedule a task: failed to start the thread (threads=0, jobs=0). (CANNOT_SCHEDULE_TASK) (version 25.3.6.10636.altinitytest (altinity build)) (from [::1]:41494) (comment: 02053_INSERT_SELECT_MATERIALIZED.sql) (query 3, line 4) (in query: -- Due to insert_null_as_default A became Null and X became -1 insert into data_02053 select 1, 42;), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000fccaeeb 4. /build/src/Common/ThreadPool.cpp:275: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000fccc813 5. /build/src/Common/ThreadPool.cpp:308: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fcc8286 6. /build/src/Common/ThreadPool.cpp:494: ThreadPoolImpl>::scheduleOrThrowOnError(std::function, Priority) @ 0x000000000fcc7a0e 7. /build/src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::spawnThreadsImpl() @ 0x00000000169b2c0c 8. /build/src/Processors/Executors/PipelineExecutor.cpp:394: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x00000000169b0ba7 9. /build/src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x00000000169b03f4 10. /build/src/Processors/Executors/CompletedPipelineExecutor.cpp:42: void std::__function::__policy_invoker::__call_impl[abi:se190107]::ThreadFromGlobalPoolImpl(DB::CompletedPipelineExecutor::execute()::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169af7e1 11. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc3d92 12. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fcca080 13. ? @ 0x00007fbc6213eac3 14. ? @ 0x00007fbc621d0850 2025.07.28 11:58:23.584656 [ 17208 ] {} 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. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000fccaeeb 4. /build/src/Common/ThreadPool.cpp:275: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000fccc813 5. /build/src/Common/ThreadPool.cpp:308: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fcc8286 6. /build/src/Common/ThreadPool.cpp:494: ThreadPoolImpl>::scheduleOrThrowOnError(std::function, Priority) @ 0x000000000fcc7a0e 7. /build/src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::spawnThreadsImpl() @ 0x00000000169b2c0c 8. /build/src/Processors/Executors/PipelineExecutor.cpp:394: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x00000000169b0ba7 9. /build/src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x00000000169b03f4 10. /build/src/Processors/Executors/CompletedPipelineExecutor.cpp:42: void std::__function::__policy_invoker::__call_impl[abi:se190107]::ThreadFromGlobalPoolImpl(DB::CompletedPipelineExecutor::execute()::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169af7e1 11. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc3d92 12. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fcca080 13. ? @ 0x00007fbc6213eac3 14. ? @ 0x00007fbc621d0850 Job's origin stack trace: 0. /build/src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000000fc33b84 1. /build/src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000000fcc2ea7 2. /build/src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fcc535c 3. /build/src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000000fcc584d 4. /build/src/Common/ThreadPool.h:279: DB::CompletedPipelineExecutor::execute() @ 0x00000000169af267 5. /build/src/Server/TCPHandler.cpp:707: DB::TCPHandler::runImpl() @ 0x00000000168e6b2e 6. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 7. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 8. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 9. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 10. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 11. ? @ 0x00007fbc6213eac3 12. ? @ 0x00007fbc621d0850 2025.07.28 11:58:23.652741 [ 3976 ] {} test_13.rmt2 (7f9b740d-015c-470e-8cc6-8ba33be0dc63): auto DB::StorageReplicatedMergeTree::processQueueEntry(ReplicatedMergeTreeQueue::SelectedEntryPtr)::(anonymous class)::operator()(LogEntryPtr &) const: Code: 86. DB::HTTPException: Received error from remote server http://146b4357c08d:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Ftest%2F01165%2Ftest_13%2Frmt%2Freplicas%2F1&part=20250728_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.6.10636.altinitytest (altinity build)) '. (RECEIVED_ERROR_FROM_REMOTE_IO_SERVER), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.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 const&, int&&, String const&, unsigned long&&, String const&) @ 0x000000000feda8d9 4. /build/src/IO/HTTPCommon.cpp:104: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x000000000feda6e2 5. /build/src/IO/HTTPCommon.cpp:93: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x000000000feda537 6. /build/src/IO/ReadWriteBufferFromHTTP.cpp:277: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x000000001184a4c4 7. /build/src/IO/ReadWriteBufferFromHTTP.cpp:285: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x000000001184a615 8. /build/src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x000000001184ae59 9. /build/src/IO/ReadWriteBufferFromHTTP.cpp:472: void std::__function::__policy_invoker::__call_impl[abi:se190107]>(std::__function::__policy_storage const*) @ 0x000000001184cedd 10. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001184858b 11. /build/src/IO/ReadWriteBufferFromHTTP.cpp:465: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x000000001184bf0b 12. /build/src/IO/ReadBuffer.h:60: DB::ReadBuffer::next() @ 0x000000000a148c7b 13. /build/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) @ 0x0000000011849fb2 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]>&)>&, 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&) @ 0x0000000011841980 15. /build/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) @ 0x000000001621208e 16. /build/src/Storages/StorageReplicatedMergeTree.cpp:5228: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl[abi:se190107] const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000015f9a5fe 17. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000015ed8bfd 18. /build/src/Storages/StorageReplicatedMergeTree.cpp:2514: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x0000000015ec9aab 19. /build/src/Storages/StorageReplicatedMergeTree.cpp:2349: DB::StorageReplicatedMergeTree::executeLogEntry(DB::ReplicatedMergeTreeLogEntry&) @ 0x0000000015eba91b 20. /build/src/Storages/StorageReplicatedMergeTree.cpp:3876: bool std::__function::__policy_invoker&)>::__call_impl[abi:se190107])::$_1, bool (std::shared_ptr&)>>(std::__function::__policy_storage const*, std::shared_ptr&) @ 0x0000000015f9837e 21. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000165d6fc3 22. /build/src/Storages/StorageReplicatedMergeTree.cpp:3872: DB::StorageReplicatedMergeTree::processQueueEntry(std::shared_ptr) @ 0x0000000015efc18a 23. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001624c1b2 24. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000162f9c70 25. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x00000000162fa55a 26. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc6653 27. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000000fccc4c3 28. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc3d92 29. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fcca080 30. ? @ 0x00007fbc6213eac3 31. ? @ 0x00007fbc621d0850 (version 25.3.6.10636.altinitytest (altinity build)) 2025.07.28 11:58:23.896184 [ 3965 ] {} test_13.rmt2 (7f9b740d-015c-470e-8cc6-8ba33be0dc63): auto DB::StorageReplicatedMergeTree::processQueueEntry(ReplicatedMergeTreeQueue::SelectedEntryPtr)::(anonymous class)::operator()(LogEntryPtr &) const: Code: 86. DB::HTTPException: Received error from remote server http://146b4357c08d:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Ftest%2F01165%2Ftest_13%2Frmt%2Freplicas%2F1&part=20250728_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.6.10636.altinitytest (altinity build)) '. (RECEIVED_ERROR_FROM_REMOTE_IO_SERVER), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.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 const&, int&&, String const&, unsigned long&&, String const&) @ 0x000000000feda8d9 4. /build/src/IO/HTTPCommon.cpp:104: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x000000000feda6e2 5. /build/src/IO/HTTPCommon.cpp:93: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x000000000feda537 6. /build/src/IO/ReadWriteBufferFromHTTP.cpp:277: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x000000001184a4c4 7. /build/src/IO/ReadWriteBufferFromHTTP.cpp:285: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x000000001184a615 8. /build/src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x000000001184ae59 9. /build/src/IO/ReadWriteBufferFromHTTP.cpp:472: void std::__function::__policy_invoker::__call_impl[abi:se190107]>(std::__function::__policy_storage const*) @ 0x000000001184cedd 10. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001184858b 11. /build/src/IO/ReadWriteBufferFromHTTP.cpp:465: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x000000001184bf0b 12. /build/src/IO/ReadBuffer.h:60: DB::ReadBuffer::next() @ 0x000000000a148c7b 13. /build/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) @ 0x0000000011849fb2 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]>&)>&, 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&) @ 0x0000000011841980 15. /build/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) @ 0x000000001621208e 16. /build/src/Storages/StorageReplicatedMergeTree.cpp:5228: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl[abi:se190107] const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000015f9a5fe 17. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000015ed8bfd 18. /build/src/Storages/StorageReplicatedMergeTree.cpp:2514: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x0000000015ec9aab 19. /build/src/Storages/StorageReplicatedMergeTree.cpp:2349: DB::StorageReplicatedMergeTree::executeLogEntry(DB::ReplicatedMergeTreeLogEntry&) @ 0x0000000015eba91b 20. /build/src/Storages/StorageReplicatedMergeTree.cpp:3876: bool std::__function::__policy_invoker&)>::__call_impl[abi:se190107])::$_1, bool (std::shared_ptr&)>>(std::__function::__policy_storage const*, std::shared_ptr&) @ 0x0000000015f9837e 21. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000165d6fc3 22. /build/src/Storages/StorageReplicatedMergeTree.cpp:3872: DB::StorageReplicatedMergeTree::processQueueEntry(std::shared_ptr) @ 0x0000000015efc18a 23. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001624c1b2 24. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000162f9c70 25. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x00000000162fa55a 26. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc6653 27. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000000fccc4c3 28. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc3d92 29. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fcca080 30. ? @ 0x00007fbc6213eac3 31. ? @ 0x00007fbc621d0850 (version 25.3.6.10636.altinitytest (altinity build)) 2025.07.28 11:58:24.105875 [ 3961 ] {} test_13.rmt2 (7f9b740d-015c-470e-8cc6-8ba33be0dc63): auto DB::StorageReplicatedMergeTree::processQueueEntry(ReplicatedMergeTreeQueue::SelectedEntryPtr)::(anonymous class)::operator()(LogEntryPtr &) const: Code: 86. DB::HTTPException: Received error from remote server http://146b4357c08d:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Ftest%2F01165%2Ftest_13%2Frmt%2Freplicas%2F1&part=20250728_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.6.10636.altinitytest (altinity build)) '. (RECEIVED_ERROR_FROM_REMOTE_IO_SERVER), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.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 const&, int&&, String const&, unsigned long&&, String const&) @ 0x000000000feda8d9 4. /build/src/IO/HTTPCommon.cpp:104: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x000000000feda6e2 5. /build/src/IO/HTTPCommon.cpp:93: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x000000000feda537 6. /build/src/IO/ReadWriteBufferFromHTTP.cpp:277: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x000000001184a4c4 7. /build/src/IO/ReadWriteBufferFromHTTP.cpp:285: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x000000001184a615 8. /build/src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x000000001184ae59 9. /build/src/IO/ReadWriteBufferFromHTTP.cpp:472: void std::__function::__policy_invoker::__call_impl[abi:se190107]>(std::__function::__policy_storage const*) @ 0x000000001184cedd 10. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001184858b 11. /build/src/IO/ReadWriteBufferFromHTTP.cpp:465: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x000000001184bf0b 12. /build/src/IO/ReadBuffer.h:60: DB::ReadBuffer::next() @ 0x000000000a148c7b 13. /build/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) @ 0x0000000011849fb2 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]>&)>&, 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&) @ 0x0000000011841980 15. /build/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) @ 0x000000001621208e 16. /build/src/Storages/StorageReplicatedMergeTree.cpp:5228: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl[abi:se190107] const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000015f9a5fe 17. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000015ed8bfd 18. /build/src/Storages/StorageReplicatedMergeTree.cpp:2514: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x0000000015ec9aab 19. /build/src/Storages/StorageReplicatedMergeTree.cpp:2349: DB::StorageReplicatedMergeTree::executeLogEntry(DB::ReplicatedMergeTreeLogEntry&) @ 0x0000000015eba91b 20. /build/src/Storages/StorageReplicatedMergeTree.cpp:3876: bool std::__function::__policy_invoker&)>::__call_impl[abi:se190107])::$_1, bool (std::shared_ptr&)>>(std::__function::__policy_storage const*, std::shared_ptr&) @ 0x0000000015f9837e 21. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000165d6fc3 22. /build/src/Storages/StorageReplicatedMergeTree.cpp:3872: DB::StorageReplicatedMergeTree::processQueueEntry(std::shared_ptr) @ 0x0000000015efc18a 23. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001624c1b2 24. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000162f9c70 25. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x00000000162fa55a 26. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc6653 27. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000000fccc4c3 28. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc3d92 29. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fcca080 30. ? @ 0x00007fbc6213eac3 31. ? @ 0x00007fbc621d0850 (version 25.3.6.10636.altinitytest (altinity build)) 2025.07.28 11:58:24.746124 [ 3967 ] {} test_13.rmt2 (7f9b740d-015c-470e-8cc6-8ba33be0dc63): auto DB::StorageReplicatedMergeTree::processQueueEntry(ReplicatedMergeTreeQueue::SelectedEntryPtr)::(anonymous class)::operator()(LogEntryPtr &) const: Code: 86. DB::HTTPException: Received error from remote server http://146b4357c08d:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Ftest%2F01165%2Ftest_13%2Frmt%2Freplicas%2F1&part=20250728_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.6.10636.altinitytest (altinity build)) '. (RECEIVED_ERROR_FROM_REMOTE_IO_SERVER), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.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 const&, int&&, String const&, unsigned long&&, String const&) @ 0x000000000feda8d9 4. /build/src/IO/HTTPCommon.cpp:104: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x000000000feda6e2 5. /build/src/IO/HTTPCommon.cpp:93: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x000000000feda537 6. /build/src/IO/ReadWriteBufferFromHTTP.cpp:277: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x000000001184a4c4 7. /build/src/IO/ReadWriteBufferFromHTTP.cpp:285: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x000000001184a615 8. /build/src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x000000001184ae59 9. /build/src/IO/ReadWriteBufferFromHTTP.cpp:472: void std::__function::__policy_invoker::__call_impl[abi:se190107]>(std::__function::__policy_storage const*) @ 0x000000001184cedd 10. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001184858b 11. /build/src/IO/ReadWriteBufferFromHTTP.cpp:465: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x000000001184bf0b 12. /build/src/IO/ReadBuffer.h:60: DB::ReadBuffer::next() @ 0x000000000a148c7b 13. /build/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) @ 0x0000000011849fb2 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]>&)>&, 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&) @ 0x0000000011841980 15. /build/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) @ 0x000000001621208e 16. /build/src/Storages/StorageReplicatedMergeTree.cpp:5228: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl[abi:se190107] const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000015f9a5fe 17. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000015ed8bfd 18. /build/src/Storages/StorageReplicatedMergeTree.cpp:2514: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x0000000015ec9aab 19. /build/src/Storages/StorageReplicatedMergeTree.cpp:2349: DB::StorageReplicatedMergeTree::executeLogEntry(DB::ReplicatedMergeTreeLogEntry&) @ 0x0000000015eba91b 20. /build/src/Storages/StorageReplicatedMergeTree.cpp:3876: bool std::__function::__policy_invoker&)>::__call_impl[abi:se190107])::$_1, bool (std::shared_ptr&)>>(std::__function::__policy_storage const*, std::shared_ptr&) @ 0x0000000015f9837e 21. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000165d6fc3 22. /build/src/Storages/StorageReplicatedMergeTree.cpp:3872: DB::StorageReplicatedMergeTree::processQueueEntry(std::shared_ptr) @ 0x0000000015efc18a 23. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001624c1b2 24. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000162f9c70 25. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x00000000162fa55a 26. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc6653 27. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000000fccc4c3 28. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc3d92 29. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fcca080 30. ? @ 0x00007fbc6213eac3 31. ? @ 0x00007fbc621d0850 (version 25.3.6.10636.altinitytest (altinity build)) 2025.07.28 11:58:25.095421 [ 3974 ] {} test_13.rmt2 (7f9b740d-015c-470e-8cc6-8ba33be0dc63): auto DB::StorageReplicatedMergeTree::processQueueEntry(ReplicatedMergeTreeQueue::SelectedEntryPtr)::(anonymous class)::operator()(LogEntryPtr &) const: Code: 86. DB::HTTPException: Received error from remote server http://146b4357c08d:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Ftest%2F01165%2Ftest_13%2Frmt%2Freplicas%2F1&part=20250728_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.6.10636.altinitytest (altinity build)) '. (RECEIVED_ERROR_FROM_REMOTE_IO_SERVER), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.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 const&, int&&, String const&, unsigned long&&, String const&) @ 0x000000000feda8d9 4. /build/src/IO/HTTPCommon.cpp:104: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x000000000feda6e2 5. /build/src/IO/HTTPCommon.cpp:93: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x000000000feda537 6. /build/src/IO/ReadWriteBufferFromHTTP.cpp:277: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x000000001184a4c4 7. /build/src/IO/ReadWriteBufferFromHTTP.cpp:285: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x000000001184a615 8. /build/src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x000000001184ae59 9. /build/src/IO/ReadWriteBufferFromHTTP.cpp:472: void std::__function::__policy_invoker::__call_impl[abi:se190107]>(std::__function::__policy_storage const*) @ 0x000000001184cedd 10. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001184858b 11. /build/src/IO/ReadWriteBufferFromHTTP.cpp:465: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x000000001184bf0b 12. /build/src/IO/ReadBuffer.h:60: DB::ReadBuffer::next() @ 0x000000000a148c7b 13. /build/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) @ 0x0000000011849fb2 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]>&)>&, 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&) @ 0x0000000011841980 15. /build/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) @ 0x000000001621208e 16. /build/src/Storages/StorageReplicatedMergeTree.cpp:5228: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl[abi:se190107] const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000015f9a5fe 17. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000015ed8bfd 18. /build/src/Storages/StorageReplicatedMergeTree.cpp:2514: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x0000000015ec9aab 19. /build/src/Storages/StorageReplicatedMergeTree.cpp:2349: DB::StorageReplicatedMergeTree::executeLogEntry(DB::ReplicatedMergeTreeLogEntry&) @ 0x0000000015eba91b 20. /build/src/Storages/StorageReplicatedMergeTree.cpp:3876: bool std::__function::__policy_invoker&)>::__call_impl[abi:se190107])::$_1, bool (std::shared_ptr&)>>(std::__function::__policy_storage const*, std::shared_ptr&) @ 0x0000000015f9837e 21. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000165d6fc3 22. /build/src/Storages/StorageReplicatedMergeTree.cpp:3872: DB::StorageReplicatedMergeTree::processQueueEntry(std::shared_ptr) @ 0x0000000015efc18a 23. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001624c1b2 24. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000162f9c70 25. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x00000000162fa55a 26. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc6653 27. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000000fccc4c3 28. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc3d92 29. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fcca080 30. ? @ 0x00007fbc6213eac3 31. ? @ 0x00007fbc621d0850 (version 25.3.6.10636.altinitytest (altinity build)) 2025.07.28 11:58:25.680361 [ 3960 ] {} test_13.rmt2 (7f9b740d-015c-470e-8cc6-8ba33be0dc63): auto DB::StorageReplicatedMergeTree::processQueueEntry(ReplicatedMergeTreeQueue::SelectedEntryPtr)::(anonymous class)::operator()(LogEntryPtr &) const: Code: 86. DB::HTTPException: Received error from remote server http://146b4357c08d:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Ftest%2F01165%2Ftest_13%2Frmt%2Freplicas%2F1&part=20250728_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.6.10636.altinitytest (altinity build)) '. (RECEIVED_ERROR_FROM_REMOTE_IO_SERVER), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.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 const&, int&&, String const&, unsigned long&&, String const&) @ 0x000000000feda8d9 4. /build/src/IO/HTTPCommon.cpp:104: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x000000000feda6e2 5. /build/src/IO/HTTPCommon.cpp:93: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x000000000feda537 6. /build/src/IO/ReadWriteBufferFromHTTP.cpp:277: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x000000001184a4c4 7. /build/src/IO/ReadWriteBufferFromHTTP.cpp:285: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x000000001184a615 8. /build/src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x000000001184ae59 9. /build/src/IO/ReadWriteBufferFromHTTP.cpp:472: void std::__function::__policy_invoker::__call_impl[abi:se190107]>(std::__function::__policy_storage const*) @ 0x000000001184cedd 10. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001184858b 11. /build/src/IO/ReadWriteBufferFromHTTP.cpp:465: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x000000001184bf0b 12. /build/src/IO/ReadBuffer.h:60: DB::ReadBuffer::next() @ 0x000000000a148c7b 13. /build/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) @ 0x0000000011849fb2 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]>&)>&, 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&) @ 0x0000000011841980 15. /build/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) @ 0x000000001621208e 16. /build/src/Storages/StorageReplicatedMergeTree.cpp:5228: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl[abi:se190107] const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000015f9a5fe 17. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000015ed8bfd 18. /build/src/Storages/StorageReplicatedMergeTree.cpp:2514: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x0000000015ec9aab 19. /build/src/Storages/StorageReplicatedMergeTree.cpp:2349: DB::StorageReplicatedMergeTree::executeLogEntry(DB::ReplicatedMergeTreeLogEntry&) @ 0x0000000015eba91b 20. /build/src/Storages/StorageReplicatedMergeTree.cpp:3876: bool std::__function::__policy_invoker&)>::__call_impl[abi:se190107])::$_1, bool (std::shared_ptr&)>>(std::__function::__policy_storage const*, std::shared_ptr&) @ 0x0000000015f9837e 21. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000165d6fc3 22. /build/src/Storages/StorageReplicatedMergeTree.cpp:3872: DB::StorageReplicatedMergeTree::processQueueEntry(std::shared_ptr) @ 0x0000000015efc18a 23. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001624c1b2 24. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000162f9c70 25. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x00000000162fa55a 26. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc6653 27. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000000fccc4c3 28. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc3d92 29. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fcca080 30. ? @ 0x00007fbc6213eac3 31. ? @ 0x00007fbc621d0850 (version 25.3.6.10636.altinitytest (altinity build)) 2025.07.28 11:58:26.297722 [ 3972 ] {} test_13.rmt2 (7f9b740d-015c-470e-8cc6-8ba33be0dc63): auto DB::StorageReplicatedMergeTree::processQueueEntry(ReplicatedMergeTreeQueue::SelectedEntryPtr)::(anonymous class)::operator()(LogEntryPtr &) const: Code: 86. DB::HTTPException: Received error from remote server http://146b4357c08d:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Ftest%2F01165%2Ftest_13%2Frmt%2Freplicas%2F1&part=20250728_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.6.10636.altinitytest (altinity build)) '. (RECEIVED_ERROR_FROM_REMOTE_IO_SERVER), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.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 const&, int&&, String const&, unsigned long&&, String const&) @ 0x000000000feda8d9 4. /build/src/IO/HTTPCommon.cpp:104: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x000000000feda6e2 5. /build/src/IO/HTTPCommon.cpp:93: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x000000000feda537 6. /build/src/IO/ReadWriteBufferFromHTTP.cpp:277: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x000000001184a4c4 7. /build/src/IO/ReadWriteBufferFromHTTP.cpp:285: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x000000001184a615 8. /build/src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x000000001184ae59 9. /build/src/IO/ReadWriteBufferFromHTTP.cpp:472: void std::__function::__policy_invoker::__call_impl[abi:se190107]>(std::__function::__policy_storage const*) @ 0x000000001184cedd 10. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001184858b 11. /build/src/IO/ReadWriteBufferFromHTTP.cpp:465: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x000000001184bf0b 12. /build/src/IO/ReadBuffer.h:60: DB::ReadBuffer::next() @ 0x000000000a148c7b 13. /build/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) @ 0x0000000011849fb2 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]>&)>&, 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&) @ 0x0000000011841980 15. /build/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) @ 0x000000001621208e 16. /build/src/Storages/StorageReplicatedMergeTree.cpp:5228: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl[abi:se190107] const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000015f9a5fe 17. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000015ed8bfd 18. /build/src/Storages/StorageReplicatedMergeTree.cpp:2514: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x0000000015ec9aab 19. /build/src/Storages/StorageReplicatedMergeTree.cpp:2349: DB::StorageReplicatedMergeTree::executeLogEntry(DB::ReplicatedMergeTreeLogEntry&) @ 0x0000000015eba91b 20. /build/src/Storages/StorageReplicatedMergeTree.cpp:3876: bool std::__function::__policy_invoker&)>::__call_impl[abi:se190107])::$_1, bool (std::shared_ptr&)>>(std::__function::__policy_storage const*, std::shared_ptr&) @ 0x0000000015f9837e 21. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000165d6fc3 22. /build/src/Storages/StorageReplicatedMergeTree.cpp:3872: DB::StorageReplicatedMergeTree::processQueueEntry(std::shared_ptr) @ 0x0000000015efc18a 23. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001624c1b2 24. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000162f9c70 25. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x00000000162fa55a 26. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc6653 27. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000000fccc4c3 28. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc3d92 29. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fcca080 30. ? @ 0x00007fbc6213eac3 31. ? @ 0x00007fbc621d0850 (version 25.3.6.10636.altinitytest (altinity build)) 2025.07.28 11:58:27.253914 [ 3976 ] {} test_13.rmt2 (7f9b740d-015c-470e-8cc6-8ba33be0dc63): auto DB::StorageReplicatedMergeTree::processQueueEntry(ReplicatedMergeTreeQueue::SelectedEntryPtr)::(anonymous class)::operator()(LogEntryPtr &) const: Code: 86. DB::HTTPException: Received error from remote server http://146b4357c08d:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Ftest%2F01165%2Ftest_13%2Frmt%2Freplicas%2F1&part=20250728_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.6.10636.altinitytest (altinity build)) '. (RECEIVED_ERROR_FROM_REMOTE_IO_SERVER), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.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 const&, int&&, String const&, unsigned long&&, String const&) @ 0x000000000feda8d9 4. /build/src/IO/HTTPCommon.cpp:104: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x000000000feda6e2 5. /build/src/IO/HTTPCommon.cpp:93: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x000000000feda537 6. /build/src/IO/ReadWriteBufferFromHTTP.cpp:277: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x000000001184a4c4 7. /build/src/IO/ReadWriteBufferFromHTTP.cpp:285: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x000000001184a615 8. /build/src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x000000001184ae59 9. /build/src/IO/ReadWriteBufferFromHTTP.cpp:472: void std::__function::__policy_invoker::__call_impl[abi:se190107]>(std::__function::__policy_storage const*) @ 0x000000001184cedd 10. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001184858b 11. /build/src/IO/ReadWriteBufferFromHTTP.cpp:465: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x000000001184bf0b 12. /build/src/IO/ReadBuffer.h:60: DB::ReadBuffer::next() @ 0x000000000a148c7b 13. /build/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) @ 0x0000000011849fb2 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]>&)>&, 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&) @ 0x0000000011841980 15. /build/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) @ 0x000000001621208e 16. /build/src/Storages/StorageReplicatedMergeTree.cpp:5228: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl[abi:se190107] const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000015f9a5fe 17. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000015ed8bfd 18. /build/src/Storages/StorageReplicatedMergeTree.cpp:2514: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x0000000015ec9aab 19. /build/src/Storages/StorageReplicatedMergeTree.cpp:2349: DB::StorageReplicatedMergeTree::executeLogEntry(DB::ReplicatedMergeTreeLogEntry&) @ 0x0000000015eba91b 20. /build/src/Storages/StorageReplicatedMergeTree.cpp:3876: bool std::__function::__policy_invoker&)>::__call_impl[abi:se190107])::$_1, bool (std::shared_ptr&)>>(std::__function::__policy_storage const*, std::shared_ptr&) @ 0x0000000015f9837e 21. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000165d6fc3 22. /build/src/Storages/StorageReplicatedMergeTree.cpp:3872: DB::StorageReplicatedMergeTree::processQueueEntry(std::shared_ptr) @ 0x0000000015efc18a 23. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001624c1b2 24. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000162f9c70 25. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x00000000162fa55a 26. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc6653 27. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000000fccc4c3 28. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc3d92 29. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fcca080 30. ? @ 0x00007fbc6213eac3 31. ? @ 0x00007fbc621d0850 (version 25.3.6.10636.altinitytest (altinity build)) 2025.07.28 11:58:27.829799 [ 3971 ] {} test_13.rmt2 (7f9b740d-015c-470e-8cc6-8ba33be0dc63): auto DB::StorageReplicatedMergeTree::processQueueEntry(ReplicatedMergeTreeQueue::SelectedEntryPtr)::(anonymous class)::operator()(LogEntryPtr &) const: Code: 86. DB::HTTPException: Received error from remote server http://146b4357c08d:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Ftest%2F01165%2Ftest_13%2Frmt%2Freplicas%2F1&part=20250728_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.6.10636.altinitytest (altinity build)) '. (RECEIVED_ERROR_FROM_REMOTE_IO_SERVER), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.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 const&, int&&, String const&, unsigned long&&, String const&) @ 0x000000000feda8d9 4. /build/src/IO/HTTPCommon.cpp:104: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x000000000feda6e2 5. /build/src/IO/HTTPCommon.cpp:93: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x000000000feda537 6. /build/src/IO/ReadWriteBufferFromHTTP.cpp:277: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x000000001184a4c4 7. /build/src/IO/ReadWriteBufferFromHTTP.cpp:285: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x000000001184a615 8. /build/src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x000000001184ae59 9. /build/src/IO/ReadWriteBufferFromHTTP.cpp:472: void std::__function::__policy_invoker::__call_impl[abi:se190107]>(std::__function::__policy_storage const*) @ 0x000000001184cedd 10. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001184858b 11. /build/src/IO/ReadWriteBufferFromHTTP.cpp:465: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x000000001184bf0b 12. /build/src/IO/ReadBuffer.h:60: DB::ReadBuffer::next() @ 0x000000000a148c7b 13. /build/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) @ 0x0000000011849fb2 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]>&)>&, 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&) @ 0x0000000011841980 15. /build/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) @ 0x000000001621208e 16. /build/src/Storages/StorageReplicatedMergeTree.cpp:5228: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl[abi:se190107] const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000015f9a5fe 17. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000015ed8bfd 18. /build/src/Storages/StorageReplicatedMergeTree.cpp:2514: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x0000000015ec9aab 19. /build/src/Storages/StorageReplicatedMergeTree.cpp:2349: DB::StorageReplicatedMergeTree::executeLogEntry(DB::ReplicatedMergeTreeLogEntry&) @ 0x0000000015eba91b 20. /build/src/Storages/StorageReplicatedMergeTree.cpp:3876: bool std::__function::__policy_invoker&)>::__call_impl[abi:se190107])::$_1, bool (std::shared_ptr&)>>(std::__function::__policy_storage const*, std::shared_ptr&) @ 0x0000000015f9837e 21. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000165d6fc3 22. /build/src/Storages/StorageReplicatedMergeTree.cpp:3872: DB::StorageReplicatedMergeTree::processQueueEntry(std::shared_ptr) @ 0x0000000015efc18a 23. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001624c1b2 24. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000162f9c70 25. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x00000000162fa55a 26. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc6653 27. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000000fccc4c3 28. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc3d92 29. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fcca080 30. ? @ 0x00007fbc6213eac3 31. ? @ 0x00007fbc621d0850 (version 25.3.6.10636.altinitytest (altinity build)) 2025.07.28 11:58:28.697989 [ 3967 ] {} test_13.rmt2 (7f9b740d-015c-470e-8cc6-8ba33be0dc63): auto DB::StorageReplicatedMergeTree::processQueueEntry(ReplicatedMergeTreeQueue::SelectedEntryPtr)::(anonymous class)::operator()(LogEntryPtr &) const: Code: 86. DB::HTTPException: Received error from remote server http://146b4357c08d:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Ftest%2F01165%2Ftest_13%2Frmt%2Freplicas%2F1&part=20250728_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.6.10636.altinitytest (altinity build)) '. (RECEIVED_ERROR_FROM_REMOTE_IO_SERVER), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.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 const&, int&&, String const&, unsigned long&&, String const&) @ 0x000000000feda8d9 4. /build/src/IO/HTTPCommon.cpp:104: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x000000000feda6e2 5. /build/src/IO/HTTPCommon.cpp:93: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x000000000feda537 6. /build/src/IO/ReadWriteBufferFromHTTP.cpp:277: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x000000001184a4c4 7. /build/src/IO/ReadWriteBufferFromHTTP.cpp:285: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x000000001184a615 8. /build/src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x000000001184ae59 9. /build/src/IO/ReadWriteBufferFromHTTP.cpp:472: void std::__function::__policy_invoker::__call_impl[abi:se190107]>(std::__function::__policy_storage const*) @ 0x000000001184cedd 10. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001184858b 11. /build/src/IO/ReadWriteBufferFromHTTP.cpp:465: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x000000001184bf0b 12. /build/src/IO/ReadBuffer.h:60: DB::ReadBuffer::next() @ 0x000000000a148c7b 13. /build/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) @ 0x0000000011849fb2 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]>&)>&, 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&) @ 0x0000000011841980 15. /build/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) @ 0x000000001621208e 16. /build/src/Storages/StorageReplicatedMergeTree.cpp:5228: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl[abi:se190107] const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000015f9a5fe 17. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000015ed8bfd 18. /build/src/Storages/StorageReplicatedMergeTree.cpp:2514: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x0000000015ec9aab 19. /build/src/Storages/StorageReplicatedMergeTree.cpp:2349: DB::StorageReplicatedMergeTree::executeLogEntry(DB::ReplicatedMergeTreeLogEntry&) @ 0x0000000015eba91b 20. /build/src/Storages/StorageReplicatedMergeTree.cpp:3876: bool std::__function::__policy_invoker&)>::__call_impl[abi:se190107])::$_1, bool (std::shared_ptr&)>>(std::__function::__policy_storage const*, std::shared_ptr&) @ 0x0000000015f9837e 21. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000165d6fc3 22. /build/src/Storages/StorageReplicatedMergeTree.cpp:3872: DB::StorageReplicatedMergeTree::processQueueEntry(std::shared_ptr) @ 0x0000000015efc18a 23. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001624c1b2 24. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000162f9c70 25. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x00000000162fa55a 26. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc6653 27. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000000fccc4c3 28. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc3d92 29. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fcca080 30. ? @ 0x00007fbc6213eac3 31. ? @ 0x00007fbc621d0850 (version 25.3.6.10636.altinitytest (altinity build)) 2025.07.28 11:58:29.063237 [ 3968 ] {} test_13.rmt2 (7f9b740d-015c-470e-8cc6-8ba33be0dc63): auto DB::StorageReplicatedMergeTree::processQueueEntry(ReplicatedMergeTreeQueue::SelectedEntryPtr)::(anonymous class)::operator()(LogEntryPtr &) const: Code: 86. DB::HTTPException: Received error from remote server http://146b4357c08d:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Ftest%2F01165%2Ftest_13%2Frmt%2Freplicas%2F1&part=20250728_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.6.10636.altinitytest (altinity build)) '. (RECEIVED_ERROR_FROM_REMOTE_IO_SERVER), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.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 const&, int&&, String const&, unsigned long&&, String const&) @ 0x000000000feda8d9 4. /build/src/IO/HTTPCommon.cpp:104: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x000000000feda6e2 5. /build/src/IO/HTTPCommon.cpp:93: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x000000000feda537 6. /build/src/IO/ReadWriteBufferFromHTTP.cpp:277: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x000000001184a4c4 7. /build/src/IO/ReadWriteBufferFromHTTP.cpp:285: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x000000001184a615 8. /build/src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x000000001184ae59 9. /build/src/IO/ReadWriteBufferFromHTTP.cpp:472: void std::__function::__policy_invoker::__call_impl[abi:se190107]>(std::__function::__policy_storage const*) @ 0x000000001184cedd 10. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001184858b 11. /build/src/IO/ReadWriteBufferFromHTTP.cpp:465: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x000000001184bf0b 12. /build/src/IO/ReadBuffer.h:60: DB::ReadBuffer::next() @ 0x000000000a148c7b 13. /build/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) @ 0x0000000011849fb2 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]>&)>&, 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&) @ 0x0000000011841980 15. /build/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) @ 0x000000001621208e 16. /build/src/Storages/StorageReplicatedMergeTree.cpp:5228: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl[abi:se190107] const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000015f9a5fe 17. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000015ed8bfd 18. /build/src/Storages/StorageReplicatedMergeTree.cpp:2514: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x0000000015ec9aab 19. /build/src/Storages/StorageReplicatedMergeTree.cpp:2349: DB::StorageReplicatedMergeTree::executeLogEntry(DB::ReplicatedMergeTreeLogEntry&) @ 0x0000000015eba91b 20. /build/src/Storages/StorageReplicatedMergeTree.cpp:3876: bool std::__function::__policy_invoker&)>::__call_impl[abi:se190107])::$_1, bool (std::shared_ptr&)>>(std::__function::__policy_storage const*, std::shared_ptr&) @ 0x0000000015f9837e 21. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000165d6fc3 22. /build/src/Storages/StorageReplicatedMergeTree.cpp:3872: DB::StorageReplicatedMergeTree::processQueueEntry(std::shared_ptr) @ 0x0000000015efc18a 23. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001624c1b2 24. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000162f9c70 25. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x00000000162fa55a 26. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc6653 27. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000000fccc4c3 28. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc3d92 29. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fcca080 30. ? @ 0x00007fbc6213eac3 31. ? @ 0x00007fbc621d0850 (version 25.3.6.10636.altinitytest (altinity build)) 2025.07.28 11:58:29.714148 [ 3971 ] {} test_13.rmt2 (7f9b740d-015c-470e-8cc6-8ba33be0dc63): auto DB::StorageReplicatedMergeTree::processQueueEntry(ReplicatedMergeTreeQueue::SelectedEntryPtr)::(anonymous class)::operator()(LogEntryPtr &) const: Code: 86. DB::HTTPException: Received error from remote server http://146b4357c08d:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Ftest%2F01165%2Ftest_13%2Frmt%2Freplicas%2F1&part=20250728_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.6.10636.altinitytest (altinity build)) '. (RECEIVED_ERROR_FROM_REMOTE_IO_SERVER), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.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 const&, int&&, String const&, unsigned long&&, String const&) @ 0x000000000feda8d9 4. /build/src/IO/HTTPCommon.cpp:104: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x000000000feda6e2 5. /build/src/IO/HTTPCommon.cpp:93: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x000000000feda537 6. /build/src/IO/ReadWriteBufferFromHTTP.cpp:277: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x000000001184a4c4 7. /build/src/IO/ReadWriteBufferFromHTTP.cpp:285: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x000000001184a615 8. /build/src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x000000001184ae59 9. /build/src/IO/ReadWriteBufferFromHTTP.cpp:472: void std::__function::__policy_invoker::__call_impl[abi:se190107]>(std::__function::__policy_storage const*) @ 0x000000001184cedd 10. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001184858b 11. /build/src/IO/ReadWriteBufferFromHTTP.cpp:465: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x000000001184bf0b 12. /build/src/IO/ReadBuffer.h:60: DB::ReadBuffer::next() @ 0x000000000a148c7b 13. /build/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) @ 0x0000000011849fb2 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]>&)>&, 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&) @ 0x0000000011841980 15. /build/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) @ 0x000000001621208e 16. /build/src/Storages/StorageReplicatedMergeTree.cpp:5228: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl[abi:se190107] const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000015f9a5fe 17. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000015ed8bfd 18. /build/src/Storages/StorageReplicatedMergeTree.cpp:2514: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x0000000015ec9aab 19. /build/src/Storages/StorageReplicatedMergeTree.cpp:2349: DB::StorageReplicatedMergeTree::executeLogEntry(DB::ReplicatedMergeTreeLogEntry&) @ 0x0000000015eba91b 20. /build/src/Storages/StorageReplicatedMergeTree.cpp:3876: bool std::__function::__policy_invoker&)>::__call_impl[abi:se190107])::$_1, bool (std::shared_ptr&)>>(std::__function::__policy_storage const*, std::shared_ptr&) @ 0x0000000015f9837e 21. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000165d6fc3 22. /build/src/Storages/StorageReplicatedMergeTree.cpp:3872: DB::StorageReplicatedMergeTree::processQueueEntry(std::shared_ptr) @ 0x0000000015efc18a 23. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001624c1b2 24. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000162f9c70 25. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x00000000162fa55a 26. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc6653 27. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000000fccc4c3 28. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc3d92 29. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fcca080 30. ? @ 0x00007fbc6213eac3 31. ? @ 0x00007fbc621d0850 (version 25.3.6.10636.altinitytest (altinity build)) 2025.07.28 11:58:30.345985 [ 17208 ] {e4c5b917-b19c-4f65-8cc1-36779a4eaea3} executeQuery: Code: 43. DB::Exception: Nested type Array(String) cannot be inside Nullable type. (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.6.10636.altinitytest (altinity build)) (from [::1]:41992) (comment: 01159_combinators_with_parameters.sql) (query 6, line 6) (in query: SELECT toTypeName(topKOrNullState(10)(toString(number))) FROM numbers(100);), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x000000000a06b56b 4. /build/src/DataTypes/DataTypeNullable.cpp:31: DB::DataTypeNullable::DataTypeNullable(std::shared_ptr const&) @ 0x0000000013bf68c8 5. /build/contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: std::shared_ptr std::allocate_shared[abi:se190107], std::shared_ptr const&, 0>(std::allocator const&, std::shared_ptr const&) @ 0x00000000117f883c 6. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:851: DB::AggregateFunctionOrFill::AggregateFunctionOrFill(std::shared_ptr, std::vector, std::allocator>> const&, DB::Array const&) @ 0x00000000117f745b 7. /build/contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: std::shared_ptr> std::allocate_shared[abi:se190107], std::allocator>, std::shared_ptr const&, std::vector, std::allocator>> const&, DB::Array const&, 0>(std::allocator> const&, std::shared_ptr const&, std::vector, std::allocator>> const&, DB::Array const&) @ 0x00000000117f7278 8. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:851: DB::(anonymous namespace)::AggregateFunctionCombinatorOrFill::transformAggregateFunction(std::shared_ptr const&, DB::AggregateFunctionProperties const&, std::vector, std::allocator>> const&, DB::Array const&) const @ 0x00000000117f71e9 9. /build/src/AggregateFunctions/AggregateFunctionFactory.cpp:260: DB::AggregateFunctionFactory::getImpl(String const&, DB::NullsAction, std::vector, std::allocator>> const&, DB::Array const&, DB::AggregateFunctionProperties&, bool) const @ 0x00000000131e02f6 10. /build/src/AggregateFunctions/AggregateFunctionFactory.cpp:130: DB::AggregateFunctionFactory::get(String const&, DB::NullsAction, std::vector, std::allocator>> const&, DB::Array const&, DB::AggregateFunctionProperties&) const @ 0x00000000131df0ca 11. /build/src/AggregateFunctions/AggregateFunctionFactory.cpp:253: DB::AggregateFunctionFactory::getImpl(String const&, DB::NullsAction, std::vector, std::allocator>> const&, DB::Array const&, DB::AggregateFunctionProperties&, bool) const @ 0x00000000131e004b 12. /build/src/AggregateFunctions/AggregateFunctionFactory.cpp:130: DB::AggregateFunctionFactory::get(String const&, DB::NullsAction, std::vector, std::allocator>> const&, DB::Array const&, DB::AggregateFunctionProperties&) const @ 0x00000000131df0ca 13. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3368: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000014032fed 14. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3838: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000014019a9e 15. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3980: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000014018e31 16. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:2925: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000001402fcbd 17. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3838: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000014019a9e 18. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3980: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000014018e31 19. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:4304: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000014042fa7 20. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5605: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000014013749 21. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000140127f9 22. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000014011fce 23. /build/src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000001406ce8a 24. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000014973b42 25. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000001497268d 26. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000014974d24 27. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001492924b 28. /build/src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88641 29. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 30. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 31. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 2025.07.28 11:58:30.349274 [ 17208 ] {} TCPHandler: Code: 43. DB::Exception: Nested type Array(String) cannot be inside Nullable type. (ILLEGAL_TYPE_OF_ARGUMENT), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x000000000a06b56b 4. /build/src/DataTypes/DataTypeNullable.cpp:31: DB::DataTypeNullable::DataTypeNullable(std::shared_ptr const&) @ 0x0000000013bf68c8 5. /build/contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: std::shared_ptr std::allocate_shared[abi:se190107], std::shared_ptr const&, 0>(std::allocator const&, std::shared_ptr const&) @ 0x00000000117f883c 6. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:851: DB::AggregateFunctionOrFill::AggregateFunctionOrFill(std::shared_ptr, std::vector, std::allocator>> const&, DB::Array const&) @ 0x00000000117f745b 7. /build/contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: std::shared_ptr> std::allocate_shared[abi:se190107], std::allocator>, std::shared_ptr const&, std::vector, std::allocator>> const&, DB::Array const&, 0>(std::allocator> const&, std::shared_ptr const&, std::vector, std::allocator>> const&, DB::Array const&) @ 0x00000000117f7278 8. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:851: DB::(anonymous namespace)::AggregateFunctionCombinatorOrFill::transformAggregateFunction(std::shared_ptr const&, DB::AggregateFunctionProperties const&, std::vector, std::allocator>> const&, DB::Array const&) const @ 0x00000000117f71e9 9. /build/src/AggregateFunctions/AggregateFunctionFactory.cpp:260: DB::AggregateFunctionFactory::getImpl(String const&, DB::NullsAction, std::vector, std::allocator>> const&, DB::Array const&, DB::AggregateFunctionProperties&, bool) const @ 0x00000000131e02f6 10. /build/src/AggregateFunctions/AggregateFunctionFactory.cpp:130: DB::AggregateFunctionFactory::get(String const&, DB::NullsAction, std::vector, std::allocator>> const&, DB::Array const&, DB::AggregateFunctionProperties&) const @ 0x00000000131df0ca 11. /build/src/AggregateFunctions/AggregateFunctionFactory.cpp:253: DB::AggregateFunctionFactory::getImpl(String const&, DB::NullsAction, std::vector, std::allocator>> const&, DB::Array const&, DB::AggregateFunctionProperties&, bool) const @ 0x00000000131e004b 12. /build/src/AggregateFunctions/AggregateFunctionFactory.cpp:130: DB::AggregateFunctionFactory::get(String const&, DB::NullsAction, std::vector, std::allocator>> const&, DB::Array const&, DB::AggregateFunctionProperties&) const @ 0x00000000131df0ca 13. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3368: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000014032fed 14. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3838: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000014019a9e 15. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3980: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000014018e31 16. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:2925: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000001402fcbd 17. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3838: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000014019a9e 18. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3980: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000014018e31 19. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:4304: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000014042fa7 20. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5605: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000014013749 21. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000140127f9 22. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000014011fce 23. /build/src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000001406ce8a 24. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000014973b42 25. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000001497268d 26. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000014974d24 27. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001492924b 28. /build/src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88641 29. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 30. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 31. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 2025.07.28 11:58:30.667769 [ 4273 ] {4a4f2077-9f74-43ff-973c-54523a722aaa} executeQuery: Code: 60. DB::Exception: Table test_3.async_inserts does not exist. (UNKNOWN_TABLE) (version 25.3.6.10636.altinitytest (altinity build)) (from 0.0.0.0:0) (comment: 02015_async_inserts_stress_long.sh) (in query: INSERT INTO FUNCTION remote('127.0.0.1', 'test_3', 'async_inserts') (id, s) FORMAT Values), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000a06a8eb 4. /build/src/Databases/IDatabase.cpp:41: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x0000000013dd565f 5. /build/src/Interpreters/DatabaseCatalog.cpp:442: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x00000000144f0869 6. /build/src/Interpreters/DatabaseCatalog.cpp:976: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x00000000144f6c88 7. /build/src/Storages/getStructureOfRemoteTable.cpp:61: DB::getStructureOfRemoteTableInShard(DB::Cluster const&, DB::Cluster::ShardInfo const&, DB::StorageID const&, std::shared_ptr, std::shared_ptr const&) @ 0x0000000016052e5b 8. /build/src/Storages/getStructureOfRemoteTable.cpp:150: DB::getStructureOfRemoteTable(DB::Cluster const&, DB::StorageID const&, std::shared_ptr, std::shared_ptr const&) @ 0x0000000016055132 9. /build/src/TableFunctions/TableFunctionRemote.cpp:337: DB::TableFunctionRemote::getActualTableStructure(std::shared_ptr, bool) const @ 0x0000000011805ecb 10. /build/src/TableFunctions/TableFunctionRemote.cpp:309: DB::TableFunctionRemote::executeImpl(std::shared_ptr const&, std::shared_ptr, String const&, DB::ColumnsDescription, bool) const @ 0x00000000118056e0 11. /build/src/TableFunctions/ITableFunction.cpp:36: DB::ITableFunction::execute(std::shared_ptr const&, std::shared_ptr, String const&, DB::ColumnsDescription, bool, bool) const @ 0x00000000131e9fc3 12. /build/src/Interpreters/InterpreterInsertQuery.cpp:153: DB::InterpreterInsertQuery::getTable(DB::ASTInsertQuery&) @ 0x000000001492bba8 13. /build/src/Interpreters/InterpreterInsertQuery.cpp:829: DB::InterpreterInsertQuery::execute() @ 0x0000000014933938 14. /build/src/Interpreters/AsynchronousInsertQueue.cpp:916: DB::AsynchronousInsertQueue::processData(DB::AsynchronousInsertQueue::InsertQuery, std::unique_ptr>, std::shared_ptr, DB::AsynchronousInsertQueue::QueueShardFlushTimeHistory&) @ 0x00000000143e26b4 15. /build/src/Interpreters/AsynchronousInsertQueue.cpp:319: void std::__function::__policy_invoker::__call_impl[abi:se190107]>, std::shared_ptr, unsigned long)::$_0, void ()>>(std::__function::__policy_storage const*) @ 0x00000000143e6d04 16. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc6653 17. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000000fccc4c3 18. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc3d92 19. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fcca080 20. ? @ 0x00007fbc6213eac3 21. ? @ 0x00007fbc621d0850 2025.07.28 11:58:30.752639 [ 4273 ] {} AsynchronousInsertQueue: Failed insertion for query 'INSERT INTO FUNCTION remote('127.0.0.1', 'test_3', 'async_inserts') (id, s) FORMAT Values': Code: 60. DB::Exception: Table test_3.async_inserts does not exist. (UNKNOWN_TABLE), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000a06a8eb 4. /build/src/Databases/IDatabase.cpp:41: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x0000000013dd565f 5. /build/src/Interpreters/DatabaseCatalog.cpp:442: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x00000000144f0869 6. /build/src/Interpreters/DatabaseCatalog.cpp:976: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x00000000144f6c88 7. /build/src/Storages/getStructureOfRemoteTable.cpp:61: DB::getStructureOfRemoteTableInShard(DB::Cluster const&, DB::Cluster::ShardInfo const&, DB::StorageID const&, std::shared_ptr, std::shared_ptr const&) @ 0x0000000016052e5b 8. /build/src/Storages/getStructureOfRemoteTable.cpp:150: DB::getStructureOfRemoteTable(DB::Cluster const&, DB::StorageID const&, std::shared_ptr, std::shared_ptr const&) @ 0x0000000016055132 9. /build/src/TableFunctions/TableFunctionRemote.cpp:337: DB::TableFunctionRemote::getActualTableStructure(std::shared_ptr, bool) const @ 0x0000000011805ecb 10. /build/src/TableFunctions/TableFunctionRemote.cpp:309: DB::TableFunctionRemote::executeImpl(std::shared_ptr const&, std::shared_ptr, String const&, DB::ColumnsDescription, bool) const @ 0x00000000118056e0 11. /build/src/TableFunctions/ITableFunction.cpp:36: DB::ITableFunction::execute(std::shared_ptr const&, std::shared_ptr, String const&, DB::ColumnsDescription, bool, bool) const @ 0x00000000131e9fc3 12. /build/src/Interpreters/InterpreterInsertQuery.cpp:153: DB::InterpreterInsertQuery::getTable(DB::ASTInsertQuery&) @ 0x000000001492bba8 13. /build/src/Interpreters/InterpreterInsertQuery.cpp:829: DB::InterpreterInsertQuery::execute() @ 0x0000000014933938 14. /build/src/Interpreters/AsynchronousInsertQueue.cpp:916: DB::AsynchronousInsertQueue::processData(DB::AsynchronousInsertQueue::InsertQuery, std::unique_ptr>, std::shared_ptr, DB::AsynchronousInsertQueue::QueueShardFlushTimeHistory&) @ 0x00000000143e26b4 15. /build/src/Interpreters/AsynchronousInsertQueue.cpp:319: void std::__function::__policy_invoker::__call_impl[abi:se190107]>, std::shared_ptr, unsigned long)::$_0, void ()>>(std::__function::__policy_storage const*) @ 0x00000000143e6d04 16. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc6653 17. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000000fccc4c3 18. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc3d92 19. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fcca080 20. ? @ 0x00007fbc6213eac3 21. ? @ 0x00007fbc621d0850 (version 25.3.6.10636.altinitytest (altinity build)) 2025.07.28 11:58:30.777088 [ 3962 ] {} test_13.rmt2 (7f9b740d-015c-470e-8cc6-8ba33be0dc63): auto DB::StorageReplicatedMergeTree::processQueueEntry(ReplicatedMergeTreeQueue::SelectedEntryPtr)::(anonymous class)::operator()(LogEntryPtr &) const: Code: 86. DB::HTTPException: Received error from remote server http://146b4357c08d:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Ftest%2F01165%2Ftest_13%2Frmt%2Freplicas%2F1&part=20250728_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.6.10636.altinitytest (altinity build)) '. (RECEIVED_ERROR_FROM_REMOTE_IO_SERVER), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.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 const&, int&&, String const&, unsigned long&&, String const&) @ 0x000000000feda8d9 4. /build/src/IO/HTTPCommon.cpp:104: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x000000000feda6e2 5. /build/src/IO/HTTPCommon.cpp:93: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x000000000feda537 6. /build/src/IO/ReadWriteBufferFromHTTP.cpp:277: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x000000001184a4c4 7. /build/src/IO/ReadWriteBufferFromHTTP.cpp:285: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x000000001184a615 8. /build/src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x000000001184ae59 9. /build/src/IO/ReadWriteBufferFromHTTP.cpp:472: void std::__function::__policy_invoker::__call_impl[abi:se190107]>(std::__function::__policy_storage const*) @ 0x000000001184cedd 10. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001184858b 11. /build/src/IO/ReadWriteBufferFromHTTP.cpp:465: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x000000001184bf0b 12. /build/src/IO/ReadBuffer.h:60: DB::ReadBuffer::next() @ 0x000000000a148c7b 13. /build/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) @ 0x0000000011849fb2 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]>&)>&, 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&) @ 0x0000000011841980 15. /build/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) @ 0x000000001621208e 16. /build/src/Storages/StorageReplicatedMergeTree.cpp:5228: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl[abi:se190107] const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000015f9a5fe 17. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000015ed8bfd 18. /build/src/Storages/StorageReplicatedMergeTree.cpp:2514: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x0000000015ec9aab 19. /build/src/Storages/StorageReplicatedMergeTree.cpp:2349: DB::StorageReplicatedMergeTree::executeLogEntry(DB::ReplicatedMergeTreeLogEntry&) @ 0x0000000015eba91b 20. /build/src/Storages/StorageReplicatedMergeTree.cpp:3876: bool std::__function::__policy_invoker&)>::__call_impl[abi:se190107])::$_1, bool (std::shared_ptr&)>>(std::__function::__policy_storage const*, std::shared_ptr&) @ 0x0000000015f9837e 21. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000165d6fc3 22. /build/src/Storages/StorageReplicatedMergeTree.cpp:3872: DB::StorageReplicatedMergeTree::processQueueEntry(std::shared_ptr) @ 0x0000000015efc18a 23. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001624c1b2 24. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000162f9c70 25. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x00000000162fa55a 26. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc6653 27. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000000fccc4c3 28. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc3d92 29. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fcca080 30. ? @ 0x00007fbc6213eac3 31. ? @ 0x00007fbc621d0850 (version 25.3.6.10636.altinitytest (altinity build)) 2025.07.28 11:58:31.447164 [ 3970 ] {} test_13.rmt2 (7f9b740d-015c-470e-8cc6-8ba33be0dc63): auto DB::StorageReplicatedMergeTree::processQueueEntry(ReplicatedMergeTreeQueue::SelectedEntryPtr)::(anonymous class)::operator()(LogEntryPtr &) const: Code: 86. DB::HTTPException: Received error from remote server http://146b4357c08d:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Ftest%2F01165%2Ftest_13%2Frmt%2Freplicas%2F1&part=20250728_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.6.10636.altinitytest (altinity build)) '. (RECEIVED_ERROR_FROM_REMOTE_IO_SERVER), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.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 const&, int&&, String const&, unsigned long&&, String const&) @ 0x000000000feda8d9 4. /build/src/IO/HTTPCommon.cpp:104: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x000000000feda6e2 5. /build/src/IO/HTTPCommon.cpp:93: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x000000000feda537 6. /build/src/IO/ReadWriteBufferFromHTTP.cpp:277: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x000000001184a4c4 7. /build/src/IO/ReadWriteBufferFromHTTP.cpp:285: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x000000001184a615 8. /build/src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x000000001184ae59 9. /build/src/IO/ReadWriteBufferFromHTTP.cpp:472: void std::__function::__policy_invoker::__call_impl[abi:se190107]>(std::__function::__policy_storage const*) @ 0x000000001184cedd 10. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001184858b 11. /build/src/IO/ReadWriteBufferFromHTTP.cpp:465: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x000000001184bf0b 12. /build/src/IO/ReadBuffer.h:60: DB::ReadBuffer::next() @ 0x000000000a148c7b 13. /build/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) @ 0x0000000011849fb2 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]>&)>&, 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&) @ 0x0000000011841980 15. /build/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) @ 0x000000001621208e 16. /build/src/Storages/StorageReplicatedMergeTree.cpp:5228: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl[abi:se190107] const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000015f9a5fe 17. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000015ed8bfd 18. /build/src/Storages/StorageReplicatedMergeTree.cpp:2514: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x0000000015ec9aab 19. /build/src/Storages/StorageReplicatedMergeTree.cpp:2349: DB::StorageReplicatedMergeTree::executeLogEntry(DB::ReplicatedMergeTreeLogEntry&) @ 0x0000000015eba91b 20. /build/src/Storages/StorageReplicatedMergeTree.cpp:3876: bool std::__function::__policy_invoker&)>::__call_impl[abi:se190107])::$_1, bool (std::shared_ptr&)>>(std::__function::__policy_storage const*, std::shared_ptr&) @ 0x0000000015f9837e 21. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000165d6fc3 22. /build/src/Storages/StorageReplicatedMergeTree.cpp:3872: DB::StorageReplicatedMergeTree::processQueueEntry(std::shared_ptr) @ 0x0000000015efc18a 23. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001624c1b2 24. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000162f9c70 25. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x00000000162fa55a 26. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc6653 27. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000000fccc4c3 28. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc3d92 29. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fcca080 30. ? @ 0x00007fbc6213eac3 31. ? @ 0x00007fbc621d0850 (version 25.3.6.10636.altinitytest (altinity build)) 2025.07.28 11:58:31.672774 [ 5871 ] {ddc64441-bff7-48a1-86aa-96635330fced} executeQuery: Code: 60. DB::Exception: Table test_3.async_inserts (381129cc-eb00-436a-b221-12d159eb6193) does not exist. (UNKNOWN_TABLE) (version 25.3.6.10636.altinitytest (altinity build)) (from 0.0.0.0:0) (comment: 02015_async_inserts_stress_long.sh) (in query: INSERT INTO test_3.async_inserts (id, s) FORMAT CSV), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x000000000a06b56b 4. /build/src/Interpreters/DatabaseCatalog.cpp:359: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x00000000144f0ef6 5. /build/src/Interpreters/DatabaseCatalog.cpp:976: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x00000000144f6c88 6. /build/src/Interpreters/InterpreterInsertQuery.cpp:169: DB::InterpreterInsertQuery::getTable(DB::ASTInsertQuery&) @ 0x000000001492bf04 7. /build/src/Interpreters/InterpreterInsertQuery.cpp:829: DB::InterpreterInsertQuery::execute() @ 0x0000000014933938 8. /build/src/Interpreters/AsynchronousInsertQueue.cpp:916: DB::AsynchronousInsertQueue::processData(DB::AsynchronousInsertQueue::InsertQuery, std::unique_ptr>, std::shared_ptr, DB::AsynchronousInsertQueue::QueueShardFlushTimeHistory&) @ 0x00000000143e26b4 9. /build/src/Interpreters/AsynchronousInsertQueue.cpp:319: void std::__function::__policy_invoker::__call_impl[abi:se190107]>, std::shared_ptr, unsigned long)::$_0, void ()>>(std::__function::__policy_storage const*) @ 0x00000000143e6d04 10. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc6653 11. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000000fccc4c3 12. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc3d92 13. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fcca080 14. ? @ 0x00007fbc6213eac3 15. ? @ 0x00007fbc621d0850 2025.07.28 11:58:31.703519 [ 5871 ] {} AsynchronousInsertQueue: Failed insertion for query 'INSERT INTO test_3.async_inserts (id, s) FORMAT CSV': Code: 60. DB::Exception: Table test_3.async_inserts (381129cc-eb00-436a-b221-12d159eb6193) does not exist. (UNKNOWN_TABLE), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x000000000a06b56b 4. /build/src/Interpreters/DatabaseCatalog.cpp:359: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x00000000144f0ef6 5. /build/src/Interpreters/DatabaseCatalog.cpp:976: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x00000000144f6c88 6. /build/src/Interpreters/InterpreterInsertQuery.cpp:169: DB::InterpreterInsertQuery::getTable(DB::ASTInsertQuery&) @ 0x000000001492bf04 7. /build/src/Interpreters/InterpreterInsertQuery.cpp:829: DB::InterpreterInsertQuery::execute() @ 0x0000000014933938 8. /build/src/Interpreters/AsynchronousInsertQueue.cpp:916: DB::AsynchronousInsertQueue::processData(DB::AsynchronousInsertQueue::InsertQuery, std::unique_ptr>, std::shared_ptr, DB::AsynchronousInsertQueue::QueueShardFlushTimeHistory&) @ 0x00000000143e26b4 9. /build/src/Interpreters/AsynchronousInsertQueue.cpp:319: void std::__function::__policy_invoker::__call_impl[abi:se190107]>, std::shared_ptr, unsigned long)::$_0, void ()>>(std::__function::__policy_storage const*) @ 0x00000000143e6d04 10. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc6653 11. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000000fccc4c3 12. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc3d92 13. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fcca080 14. ? @ 0x00007fbc6213eac3 15. ? @ 0x00007fbc621d0850 (version 25.3.6.10636.altinitytest (altinity build)) 2025.07.28 11:58:32.306098 [ 3972 ] {} test_13.rmt2 (7f9b740d-015c-470e-8cc6-8ba33be0dc63): auto DB::StorageReplicatedMergeTree::processQueueEntry(ReplicatedMergeTreeQueue::SelectedEntryPtr)::(anonymous class)::operator()(LogEntryPtr &) const: Code: 86. DB::HTTPException: Received error from remote server http://146b4357c08d:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Ftest%2F01165%2Ftest_13%2Frmt%2Freplicas%2F1&part=20250728_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.6.10636.altinitytest (altinity build)) '. (RECEIVED_ERROR_FROM_REMOTE_IO_SERVER), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.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 const&, int&&, String const&, unsigned long&&, String const&) @ 0x000000000feda8d9 4. /build/src/IO/HTTPCommon.cpp:104: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x000000000feda6e2 5. /build/src/IO/HTTPCommon.cpp:93: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x000000000feda537 6. /build/src/IO/ReadWriteBufferFromHTTP.cpp:277: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x000000001184a4c4 7. /build/src/IO/ReadWriteBufferFromHTTP.cpp:285: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x000000001184a615 8. /build/src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x000000001184ae59 9. /build/src/IO/ReadWriteBufferFromHTTP.cpp:472: void std::__function::__policy_invoker::__call_impl[abi:se190107]>(std::__function::__policy_storage const*) @ 0x000000001184cedd 10. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001184858b 11. /build/src/IO/ReadWriteBufferFromHTTP.cpp:465: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x000000001184bf0b 12. /build/src/IO/ReadBuffer.h:60: DB::ReadBuffer::next() @ 0x000000000a148c7b 13. /build/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) @ 0x0000000011849fb2 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]>&)>&, 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&) @ 0x0000000011841980 15. /build/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) @ 0x000000001621208e 16. /build/src/Storages/StorageReplicatedMergeTree.cpp:5228: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl[abi:se190107] const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000015f9a5fe 17. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000015ed8bfd 18. /build/src/Storages/StorageReplicatedMergeTree.cpp:2514: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x0000000015ec9aab 19. /build/src/Storages/StorageReplicatedMergeTree.cpp:2349: DB::StorageReplicatedMergeTree::executeLogEntry(DB::ReplicatedMergeTreeLogEntry&) @ 0x0000000015eba91b 20. /build/src/Storages/StorageReplicatedMergeTree.cpp:3876: bool std::__function::__policy_invoker&)>::__call_impl[abi:se190107])::$_1, bool (std::shared_ptr&)>>(std::__function::__policy_storage const*, std::shared_ptr&) @ 0x0000000015f9837e 21. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000165d6fc3 22. /build/src/Storages/StorageReplicatedMergeTree.cpp:3872: DB::StorageReplicatedMergeTree::processQueueEntry(std::shared_ptr) @ 0x0000000015efc18a 23. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001624c1b2 24. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000162f9c70 25. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x00000000162fa55a 26. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc6653 27. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000000fccc4c3 28. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc3d92 29. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fcca080 30. ? @ 0x00007fbc6213eac3 31. ? @ 0x00007fbc621d0850 (version 25.3.6.10636.altinitytest (altinity build)) 2025.07.28 11:58:32.483878 [ 3960 ] {} test_13.rmt2 (7f9b740d-015c-470e-8cc6-8ba33be0dc63): auto DB::StorageReplicatedMergeTree::processQueueEntry(ReplicatedMergeTreeQueue::SelectedEntryPtr)::(anonymous class)::operator()(LogEntryPtr &) const: Code: 86. DB::HTTPException: Received error from remote server http://146b4357c08d:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Ftest%2F01165%2Ftest_13%2Frmt%2Freplicas%2F1&part=20250728_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.6.10636.altinitytest (altinity build)) '. (RECEIVED_ERROR_FROM_REMOTE_IO_SERVER), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.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 const&, int&&, String const&, unsigned long&&, String const&) @ 0x000000000feda8d9 4. /build/src/IO/HTTPCommon.cpp:104: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x000000000feda6e2 5. /build/src/IO/HTTPCommon.cpp:93: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x000000000feda537 6. /build/src/IO/ReadWriteBufferFromHTTP.cpp:277: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x000000001184a4c4 7. /build/src/IO/ReadWriteBufferFromHTTP.cpp:285: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x000000001184a615 8. /build/src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x000000001184ae59 9. /build/src/IO/ReadWriteBufferFromHTTP.cpp:472: void std::__function::__policy_invoker::__call_impl[abi:se190107]>(std::__function::__policy_storage const*) @ 0x000000001184cedd 10. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001184858b 11. /build/src/IO/ReadWriteBufferFromHTTP.cpp:465: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x000000001184bf0b 12. /build/src/IO/ReadBuffer.h:60: DB::ReadBuffer::next() @ 0x000000000a148c7b 13. /build/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) @ 0x0000000011849fb2 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]>&)>&, 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&) @ 0x0000000011841980 15. /build/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) @ 0x000000001621208e 16. /build/src/Storages/StorageReplicatedMergeTree.cpp:5228: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl[abi:se190107] const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000015f9a5fe 17. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000015ed8bfd 18. /build/src/Storages/StorageReplicatedMergeTree.cpp:2514: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x0000000015ec9aab 19. /build/src/Storages/StorageReplicatedMergeTree.cpp:2349: DB::StorageReplicatedMergeTree::executeLogEntry(DB::ReplicatedMergeTreeLogEntry&) @ 0x0000000015eba91b 20. /build/src/Storages/StorageReplicatedMergeTree.cpp:3876: bool std::__function::__policy_invoker&)>::__call_impl[abi:se190107])::$_1, bool (std::shared_ptr&)>>(std::__function::__policy_storage const*, std::shared_ptr&) @ 0x0000000015f9837e 21. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000165d6fc3 22. /build/src/Storages/StorageReplicatedMergeTree.cpp:3872: DB::StorageReplicatedMergeTree::processQueueEntry(std::shared_ptr) @ 0x0000000015efc18a 23. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001624c1b2 24. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000162f9c70 25. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x00000000162fa55a 26. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc6653 27. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000000fccc4c3 28. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc3d92 29. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fcca080 30. ? @ 0x00007fbc6213eac3 31. ? @ 0x00007fbc621d0850 (version 25.3.6.10636.altinitytest (altinity build)) 2025.07.28 11:58:33.550212 [ 3963 ] {} test_13.rmt2 (7f9b740d-015c-470e-8cc6-8ba33be0dc63): auto DB::StorageReplicatedMergeTree::processQueueEntry(ReplicatedMergeTreeQueue::SelectedEntryPtr)::(anonymous class)::operator()(LogEntryPtr &) const: Code: 86. DB::HTTPException: Received error from remote server http://146b4357c08d:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Ftest%2F01165%2Ftest_13%2Frmt%2Freplicas%2F1&part=20250728_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.6.10636.altinitytest (altinity build)) '. (RECEIVED_ERROR_FROM_REMOTE_IO_SERVER), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.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 const&, int&&, String const&, unsigned long&&, String const&) @ 0x000000000feda8d9 4. /build/src/IO/HTTPCommon.cpp:104: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x000000000feda6e2 5. /build/src/IO/HTTPCommon.cpp:93: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x000000000feda537 6. /build/src/IO/ReadWriteBufferFromHTTP.cpp:277: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x000000001184a4c4 7. /build/src/IO/ReadWriteBufferFromHTTP.cpp:285: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x000000001184a615 8. /build/src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x000000001184ae59 9. /build/src/IO/ReadWriteBufferFromHTTP.cpp:472: void std::__function::__policy_invoker::__call_impl[abi:se190107]>(std::__function::__policy_storage const*) @ 0x000000001184cedd 10. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001184858b 11. /build/src/IO/ReadWriteBufferFromHTTP.cpp:465: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x000000001184bf0b 12. /build/src/IO/ReadBuffer.h:60: DB::ReadBuffer::next() @ 0x000000000a148c7b 13. /build/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) @ 0x0000000011849fb2 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]>&)>&, 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&) @ 0x0000000011841980 15. /build/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) @ 0x000000001621208e 16. /build/src/Storages/StorageReplicatedMergeTree.cpp:5228: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl[abi:se190107] const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000015f9a5fe 17. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000015ed8bfd 18. /build/src/Storages/StorageReplicatedMergeTree.cpp:2514: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x0000000015ec9aab 19. /build/src/Storages/StorageReplicatedMergeTree.cpp:2349: DB::StorageReplicatedMergeTree::executeLogEntry(DB::ReplicatedMergeTreeLogEntry&) @ 0x0000000015eba91b 20. /build/src/Storages/StorageReplicatedMergeTree.cpp:3876: bool std::__function::__policy_invoker&)>::__call_impl[abi:se190107])::$_1, bool (std::shared_ptr&)>>(std::__function::__policy_storage const*, std::shared_ptr&) @ 0x0000000015f9837e 21. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000165d6fc3 22. /build/src/Storages/StorageReplicatedMergeTree.cpp:3872: DB::StorageReplicatedMergeTree::processQueueEntry(std::shared_ptr) @ 0x0000000015efc18a 23. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001624c1b2 24. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000162f9c70 25. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x00000000162fa55a 26. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc6653 27. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000000fccc4c3 28. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc3d92 29. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fcca080 30. ? @ 0x00007fbc6213eac3 31. ? @ 0x00007fbc621d0850 (version 25.3.6.10636.altinitytest (altinity build)) 2025.07.28 11:58:33.801886 [ 3965 ] {} test_13.rmt2 (7f9b740d-015c-470e-8cc6-8ba33be0dc63): auto DB::StorageReplicatedMergeTree::processQueueEntry(ReplicatedMergeTreeQueue::SelectedEntryPtr)::(anonymous class)::operator()(LogEntryPtr &) const: Code: 86. DB::HTTPException: Received error from remote server http://146b4357c08d:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Ftest%2F01165%2Ftest_13%2Frmt%2Freplicas%2F1&part=20250728_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.6.10636.altinitytest (altinity build)) '. (RECEIVED_ERROR_FROM_REMOTE_IO_SERVER), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.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 const&, int&&, String const&, unsigned long&&, String const&) @ 0x000000000feda8d9 4. /build/src/IO/HTTPCommon.cpp:104: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x000000000feda6e2 5. /build/src/IO/HTTPCommon.cpp:93: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x000000000feda537 6. /build/src/IO/ReadWriteBufferFromHTTP.cpp:277: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x000000001184a4c4 7. /build/src/IO/ReadWriteBufferFromHTTP.cpp:285: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x000000001184a615 8. /build/src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x000000001184ae59 9. /build/src/IO/ReadWriteBufferFromHTTP.cpp:472: void std::__function::__policy_invoker::__call_impl[abi:se190107]>(std::__function::__policy_storage const*) @ 0x000000001184cedd 10. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001184858b 11. /build/src/IO/ReadWriteBufferFromHTTP.cpp:465: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x000000001184bf0b 12. /build/src/IO/ReadBuffer.h:60: DB::ReadBuffer::next() @ 0x000000000a148c7b 13. /build/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) @ 0x0000000011849fb2 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]>&)>&, 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&) @ 0x0000000011841980 15. /build/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) @ 0x000000001621208e 16. /build/src/Storages/StorageReplicatedMergeTree.cpp:5228: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl[abi:se190107] const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000015f9a5fe 17. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000015ed8bfd 18. /build/src/Storages/StorageReplicatedMergeTree.cpp:2514: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x0000000015ec9aab 19. /build/src/Storages/StorageReplicatedMergeTree.cpp:2349: DB::StorageReplicatedMergeTree::executeLogEntry(DB::ReplicatedMergeTreeLogEntry&) @ 0x0000000015eba91b 20. /build/src/Storages/StorageReplicatedMergeTree.cpp:3876: bool std::__function::__policy_invoker&)>::__call_impl[abi:se190107])::$_1, bool (std::shared_ptr&)>>(std::__function::__policy_storage const*, std::shared_ptr&) @ 0x0000000015f9837e 21. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000165d6fc3 22. /build/src/Storages/StorageReplicatedMergeTree.cpp:3872: DB::StorageReplicatedMergeTree::processQueueEntry(std::shared_ptr) @ 0x0000000015efc18a 23. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001624c1b2 24. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000162f9c70 25. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x00000000162fa55a 26. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc6653 27. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000000fccc4c3 28. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc3d92 29. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fcca080 30. ? @ 0x00007fbc6213eac3 31. ? @ 0x00007fbc621d0850 (version 25.3.6.10636.altinitytest (altinity build)) 2025.07.28 11:58:34.804957 [ 3961 ] {} test_13.rmt2 (7f9b740d-015c-470e-8cc6-8ba33be0dc63): auto DB::StorageReplicatedMergeTree::processQueueEntry(ReplicatedMergeTreeQueue::SelectedEntryPtr)::(anonymous class)::operator()(LogEntryPtr &) const: Code: 86. DB::HTTPException: Received error from remote server http://146b4357c08d:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Ftest%2F01165%2Ftest_13%2Frmt%2Freplicas%2F1&part=20250728_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.6.10636.altinitytest (altinity build)) '. (RECEIVED_ERROR_FROM_REMOTE_IO_SERVER), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.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 const&, int&&, String const&, unsigned long&&, String const&) @ 0x000000000feda8d9 4. /build/src/IO/HTTPCommon.cpp:104: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x000000000feda6e2 5. /build/src/IO/HTTPCommon.cpp:93: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x000000000feda537 6. /build/src/IO/ReadWriteBufferFromHTTP.cpp:277: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x000000001184a4c4 7. /build/src/IO/ReadWriteBufferFromHTTP.cpp:285: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x000000001184a615 8. /build/src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x000000001184ae59 9. /build/src/IO/ReadWriteBufferFromHTTP.cpp:472: void std::__function::__policy_invoker::__call_impl[abi:se190107]>(std::__function::__policy_storage const*) @ 0x000000001184cedd 10. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001184858b 11. /build/src/IO/ReadWriteBufferFromHTTP.cpp:465: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x000000001184bf0b 12. /build/src/IO/ReadBuffer.h:60: DB::ReadBuffer::next() @ 0x000000000a148c7b 13. /build/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) @ 0x0000000011849fb2 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]>&)>&, 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&) @ 0x0000000011841980 15. /build/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) @ 0x000000001621208e 16. /build/src/Storages/StorageReplicatedMergeTree.cpp:5228: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl[abi:se190107] const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000015f9a5fe 17. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000015ed8bfd 18. /build/src/Storages/StorageReplicatedMergeTree.cpp:2514: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x0000000015ec9aab 19. /build/src/Storages/StorageReplicatedMergeTree.cpp:2349: DB::StorageReplicatedMergeTree::executeLogEntry(DB::ReplicatedMergeTreeLogEntry&) @ 0x0000000015eba91b 20. /build/src/Storages/StorageReplicatedMergeTree.cpp:3876: bool std::__function::__policy_invoker&)>::__call_impl[abi:se190107])::$_1, bool (std::shared_ptr&)>>(std::__function::__policy_storage const*, std::shared_ptr&) @ 0x0000000015f9837e 21. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000165d6fc3 22. /build/src/Storages/StorageReplicatedMergeTree.cpp:3872: DB::StorageReplicatedMergeTree::processQueueEntry(std::shared_ptr) @ 0x0000000015efc18a 23. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001624c1b2 24. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000162f9c70 25. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x00000000162fa55a 26. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc6653 27. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000000fccc4c3 28. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc3d92 29. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fcca080 30. ? @ 0x00007fbc6213eac3 31. ? @ 0x00007fbc621d0850 (version 25.3.6.10636.altinitytest (altinity build)) 2025.07.28 11:58:35.119005 [ 7404 ] {a70181b5-72ef-4ff7-9246-3ebd93596c4d} executeQuery: Code: 60. DB::Exception: Table test_3.async_inserts (381129cc-eb00-436a-b221-12d159eb6193) does not exist. (UNKNOWN_TABLE) (version 25.3.6.10636.altinitytest (altinity build)) (from 0.0.0.0:0) (comment: 02015_async_inserts_stress_long.sh) (in query: INSERT INTO test_3.async_inserts (id, s) FORMAT JSONEachRow), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x000000000a06b56b 4. /build/src/Interpreters/DatabaseCatalog.cpp:359: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x00000000144f0ef6 5. /build/src/Interpreters/DatabaseCatalog.cpp:976: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x00000000144f6c88 6. /build/src/Interpreters/InterpreterInsertQuery.cpp:169: DB::InterpreterInsertQuery::getTable(DB::ASTInsertQuery&) @ 0x000000001492bf04 7. /build/src/Interpreters/InterpreterInsertQuery.cpp:829: DB::InterpreterInsertQuery::execute() @ 0x0000000014933938 8. /build/src/Interpreters/AsynchronousInsertQueue.cpp:916: DB::AsynchronousInsertQueue::processData(DB::AsynchronousInsertQueue::InsertQuery, std::unique_ptr>, std::shared_ptr, DB::AsynchronousInsertQueue::QueueShardFlushTimeHistory&) @ 0x00000000143e26b4 9. /build/src/Interpreters/AsynchronousInsertQueue.cpp:319: void std::__function::__policy_invoker::__call_impl[abi:se190107]>, std::shared_ptr, unsigned long)::$_0, void ()>>(std::__function::__policy_storage const*) @ 0x00000000143e6d04 10. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc6653 11. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000000fccc4c3 12. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc3d92 13. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fcca080 14. ? @ 0x00007fbc6213eac3 15. ? @ 0x00007fbc621d0850 2025.07.28 11:58:35.126673 [ 7404 ] {} AsynchronousInsertQueue: Failed insertion for query 'INSERT INTO test_3.async_inserts (id, s) FORMAT JSONEachRow': Code: 60. DB::Exception: Table test_3.async_inserts (381129cc-eb00-436a-b221-12d159eb6193) does not exist. (UNKNOWN_TABLE), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x000000000a06b56b 4. /build/src/Interpreters/DatabaseCatalog.cpp:359: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x00000000144f0ef6 5. /build/src/Interpreters/DatabaseCatalog.cpp:976: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x00000000144f6c88 6. /build/src/Interpreters/InterpreterInsertQuery.cpp:169: DB::InterpreterInsertQuery::getTable(DB::ASTInsertQuery&) @ 0x000000001492bf04 7. /build/src/Interpreters/InterpreterInsertQuery.cpp:829: DB::InterpreterInsertQuery::execute() @ 0x0000000014933938 8. /build/src/Interpreters/AsynchronousInsertQueue.cpp:916: DB::AsynchronousInsertQueue::processData(DB::AsynchronousInsertQueue::InsertQuery, std::unique_ptr>, std::shared_ptr, DB::AsynchronousInsertQueue::QueueShardFlushTimeHistory&) @ 0x00000000143e26b4 9. /build/src/Interpreters/AsynchronousInsertQueue.cpp:319: void std::__function::__policy_invoker::__call_impl[abi:se190107]>, std::shared_ptr, unsigned long)::$_0, void ()>>(std::__function::__policy_storage const*) @ 0x00000000143e6d04 10. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc6653 11. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000000fccc4c3 12. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc3d92 13. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fcca080 14. ? @ 0x00007fbc6213eac3 15. ? @ 0x00007fbc621d0850 (version 25.3.6.10636.altinitytest (altinity build)) 2025.07.28 11:58:35.134663 [ 3974 ] {} test_13.rmt2 (7f9b740d-015c-470e-8cc6-8ba33be0dc63): auto DB::StorageReplicatedMergeTree::processQueueEntry(ReplicatedMergeTreeQueue::SelectedEntryPtr)::(anonymous class)::operator()(LogEntryPtr &) const: Code: 86. DB::HTTPException: Received error from remote server http://146b4357c08d:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Ftest%2F01165%2Ftest_13%2Frmt%2Freplicas%2F1&part=20250728_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.6.10636.altinitytest (altinity build)) '. (RECEIVED_ERROR_FROM_REMOTE_IO_SERVER), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.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 const&, int&&, String const&, unsigned long&&, String const&) @ 0x000000000feda8d9 4. /build/src/IO/HTTPCommon.cpp:104: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x000000000feda6e2 5. /build/src/IO/HTTPCommon.cpp:93: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x000000000feda537 6. /build/src/IO/ReadWriteBufferFromHTTP.cpp:277: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x000000001184a4c4 7. /build/src/IO/ReadWriteBufferFromHTTP.cpp:285: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x000000001184a615 8. /build/src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x000000001184ae59 9. /build/src/IO/ReadWriteBufferFromHTTP.cpp:472: void std::__function::__policy_invoker::__call_impl[abi:se190107]>(std::__function::__policy_storage const*) @ 0x000000001184cedd 10. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001184858b 11. /build/src/IO/ReadWriteBufferFromHTTP.cpp:465: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x000000001184bf0b 12. /build/src/IO/ReadBuffer.h:60: DB::ReadBuffer::next() @ 0x000000000a148c7b 13. /build/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) @ 0x0000000011849fb2 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]>&)>&, 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&) @ 0x0000000011841980 15. /build/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) @ 0x000000001621208e 16. /build/src/Storages/StorageReplicatedMergeTree.cpp:5228: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl[abi:se190107] const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000015f9a5fe 17. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000015ed8bfd 18. /build/src/Storages/StorageReplicatedMergeTree.cpp:2514: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x0000000015ec9aab 19. /build/src/Storages/StorageReplicatedMergeTree.cpp:2349: DB::StorageReplicatedMergeTree::executeLogEntry(DB::ReplicatedMergeTreeLogEntry&) @ 0x0000000015eba91b 20. /build/src/Storages/StorageReplicatedMergeTree.cpp:3876: bool std::__function::__policy_invoker&)>::__call_impl[abi:se190107])::$_1, bool (std::shared_ptr&)>>(std::__function::__policy_storage const*, std::shared_ptr&) @ 0x0000000015f9837e 21. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000165d6fc3 22. /build/src/Storages/StorageReplicatedMergeTree.cpp:3872: DB::StorageReplicatedMergeTree::processQueueEntry(std::shared_ptr) @ 0x0000000015efc18a 23. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001624c1b2 24. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000162f9c70 25. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x00000000162fa55a 26. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc6653 27. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000000fccc4c3 28. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc3d92 29. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fcca080 30. ? @ 0x00007fbc6213eac3 31. ? @ 0x00007fbc621d0850 (version 25.3.6.10636.altinitytest (altinity build)) 2025.07.28 11:58:36.181964 [ 3977 ] {} test_13.rmt2 (7f9b740d-015c-470e-8cc6-8ba33be0dc63): auto DB::StorageReplicatedMergeTree::processQueueEntry(ReplicatedMergeTreeQueue::SelectedEntryPtr)::(anonymous class)::operator()(LogEntryPtr &) const: Code: 86. DB::HTTPException: Received error from remote server http://146b4357c08d:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Ftest%2F01165%2Ftest_13%2Frmt%2Freplicas%2F1&part=20250728_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.6.10636.altinitytest (altinity build)) '. (RECEIVED_ERROR_FROM_REMOTE_IO_SERVER), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.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 const&, int&&, String const&, unsigned long&&, String const&) @ 0x000000000feda8d9 4. /build/src/IO/HTTPCommon.cpp:104: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x000000000feda6e2 5. /build/src/IO/HTTPCommon.cpp:93: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x000000000feda537 6. /build/src/IO/ReadWriteBufferFromHTTP.cpp:277: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x000000001184a4c4 7. /build/src/IO/ReadWriteBufferFromHTTP.cpp:285: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x000000001184a615 8. /build/src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x000000001184ae59 9. /build/src/IO/ReadWriteBufferFromHTTP.cpp:472: void std::__function::__policy_invoker::__call_impl[abi:se190107]>(std::__function::__policy_storage const*) @ 0x000000001184cedd 10. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001184858b 11. /build/src/IO/ReadWriteBufferFromHTTP.cpp:465: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x000000001184bf0b 12. /build/src/IO/ReadBuffer.h:60: DB::ReadBuffer::next() @ 0x000000000a148c7b 13. /build/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) @ 0x0000000011849fb2 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]>&)>&, 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&) @ 0x0000000011841980 15. /build/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) @ 0x000000001621208e 16. /build/src/Storages/StorageReplicatedMergeTree.cpp:5228: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl[abi:se190107] const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000015f9a5fe 17. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000015ed8bfd 18. /build/src/Storages/StorageReplicatedMergeTree.cpp:2514: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x0000000015ec9aab 19. /build/src/Storages/StorageReplicatedMergeTree.cpp:2349: DB::StorageReplicatedMergeTree::executeLogEntry(DB::ReplicatedMergeTreeLogEntry&) @ 0x0000000015eba91b 20. /build/src/Storages/StorageReplicatedMergeTree.cpp:3876: bool std::__function::__policy_invoker&)>::__call_impl[abi:se190107])::$_1, bool (std::shared_ptr&)>>(std::__function::__policy_storage const*, std::shared_ptr&) @ 0x0000000015f9837e 21. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000165d6fc3 22. /build/src/Storages/StorageReplicatedMergeTree.cpp:3872: DB::StorageReplicatedMergeTree::processQueueEntry(std::shared_ptr) @ 0x0000000015efc18a 23. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001624c1b2 24. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000162f9c70 25. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x00000000162fa55a 26. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc6653 27. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000000fccc4c3 28. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc3d92 29. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fcca080 30. ? @ 0x00007fbc6213eac3 31. ? @ 0x00007fbc621d0850 (version 25.3.6.10636.altinitytest (altinity build)) 2025.07.28 11:58:37.159552 [ 3970 ] {} test_13.rmt2 (7f9b740d-015c-470e-8cc6-8ba33be0dc63): auto DB::StorageReplicatedMergeTree::processQueueEntry(ReplicatedMergeTreeQueue::SelectedEntryPtr)::(anonymous class)::operator()(LogEntryPtr &) const: Code: 86. DB::HTTPException: Received error from remote server http://146b4357c08d:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Ftest%2F01165%2Ftest_13%2Frmt%2Freplicas%2F1&part=20250728_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.6.10636.altinitytest (altinity build)) '. (RECEIVED_ERROR_FROM_REMOTE_IO_SERVER), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.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 const&, int&&, String const&, unsigned long&&, String const&) @ 0x000000000feda8d9 4. /build/src/IO/HTTPCommon.cpp:104: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x000000000feda6e2 5. /build/src/IO/HTTPCommon.cpp:93: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x000000000feda537 6. /build/src/IO/ReadWriteBufferFromHTTP.cpp:277: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x000000001184a4c4 7. /build/src/IO/ReadWriteBufferFromHTTP.cpp:285: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x000000001184a615 8. /build/src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x000000001184ae59 9. /build/src/IO/ReadWriteBufferFromHTTP.cpp:472: void std::__function::__policy_invoker::__call_impl[abi:se190107]>(std::__function::__policy_storage const*) @ 0x000000001184cedd 10. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001184858b 11. /build/src/IO/ReadWriteBufferFromHTTP.cpp:465: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x000000001184bf0b 12. /build/src/IO/ReadBuffer.h:60: DB::ReadBuffer::next() @ 0x000000000a148c7b 13. /build/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) @ 0x0000000011849fb2 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]>&)>&, 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&) @ 0x0000000011841980 15. /build/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) @ 0x000000001621208e 16. /build/src/Storages/StorageReplicatedMergeTree.cpp:5228: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl[abi:se190107] const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000015f9a5fe 17. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000015ed8bfd 18. /build/src/Storages/StorageReplicatedMergeTree.cpp:2514: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x0000000015ec9aab 19. /build/src/Storages/StorageReplicatedMergeTree.cpp:2349: DB::StorageReplicatedMergeTree::executeLogEntry(DB::ReplicatedMergeTreeLogEntry&) @ 0x0000000015eba91b 20. /build/src/Storages/StorageReplicatedMergeTree.cpp:3876: bool std::__function::__policy_invoker&)>::__call_impl[abi:se190107])::$_1, bool (std::shared_ptr&)>>(std::__function::__policy_storage const*, std::shared_ptr&) @ 0x0000000015f9837e 21. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000165d6fc3 22. /build/src/Storages/StorageReplicatedMergeTree.cpp:3872: DB::StorageReplicatedMergeTree::processQueueEntry(std::shared_ptr) @ 0x0000000015efc18a 23. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001624c1b2 24. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000162f9c70 25. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x00000000162fa55a 26. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc6653 27. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000000fccc4c3 28. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc3d92 29. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fcca080 30. ? @ 0x00007fbc6213eac3 31. ? @ 0x00007fbc621d0850 (version 25.3.6.10636.altinitytest (altinity build)) 2025.07.28 11:58:38.120879 [ 17371 ] {60056507-0454-4866-97ea-d29d952b3fe4} executeQuery: Code: 60. DB::Exception: Table test_15.concurrent_optimize_table does not exist. (UNKNOWN_TABLE) (version 25.3.6.10636.altinitytest (altinity build)) (from [::1]:38656) (comment: 01103_optimize_drop_race_zookeeper.sh) (query 1, line 1) (in query: OPTIMIZE TABLE concurrent_optimize_table FINAL), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000a06a8eb 4. /build/src/Databases/IDatabase.cpp:41: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x0000000013dd565f 5. /build/src/Interpreters/DatabaseCatalog.cpp:442: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x00000000144f0869 6. /build/src/Interpreters/DatabaseCatalog.cpp:976: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x00000000144f6c88 7. /build/src/Interpreters/InterpreterOptimizeQuery.cpp:40: DB::InterpreterOptimizeQuery::execute() @ 0x0000000014cd71de 8. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88dc9 9. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 10. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 11. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 12. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 13. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 14. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 15. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 16. ? @ 0x00007fbc6213eac3 17. ? @ 0x00007fbc621d0850 2025.07.28 11:58:38.137007 [ 17371 ] {} TCPHandler: Code: 60. DB::Exception: Table test_15.concurrent_optimize_table does not exist. (UNKNOWN_TABLE), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000a06a8eb 4. /build/src/Databases/IDatabase.cpp:41: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x0000000013dd565f 5. /build/src/Interpreters/DatabaseCatalog.cpp:442: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x00000000144f0869 6. /build/src/Interpreters/DatabaseCatalog.cpp:976: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x00000000144f6c88 7. /build/src/Interpreters/InterpreterOptimizeQuery.cpp:40: DB::InterpreterOptimizeQuery::execute() @ 0x0000000014cd71de 8. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88dc9 9. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 10. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 11. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 12. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 13. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 14. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 15. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 16. ? @ 0x00007fbc6213eac3 17. ? @ 0x00007fbc621d0850 2025.07.28 11:58:38.227012 [ 3969 ] {} test_13.rmt2 (7f9b740d-015c-470e-8cc6-8ba33be0dc63): auto DB::StorageReplicatedMergeTree::processQueueEntry(ReplicatedMergeTreeQueue::SelectedEntryPtr)::(anonymous class)::operator()(LogEntryPtr &) const: Code: 86. DB::HTTPException: Received error from remote server http://146b4357c08d:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Ftest%2F01165%2Ftest_13%2Frmt%2Freplicas%2F1&part=20250728_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.6.10636.altinitytest (altinity build)) '. (RECEIVED_ERROR_FROM_REMOTE_IO_SERVER), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.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 const&, int&&, String const&, unsigned long&&, String const&) @ 0x000000000feda8d9 4. /build/src/IO/HTTPCommon.cpp:104: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x000000000feda6e2 5. /build/src/IO/HTTPCommon.cpp:93: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x000000000feda537 6. /build/src/IO/ReadWriteBufferFromHTTP.cpp:277: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x000000001184a4c4 7. /build/src/IO/ReadWriteBufferFromHTTP.cpp:285: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x000000001184a615 8. /build/src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x000000001184ae59 9. /build/src/IO/ReadWriteBufferFromHTTP.cpp:472: void std::__function::__policy_invoker::__call_impl[abi:se190107]>(std::__function::__policy_storage const*) @ 0x000000001184cedd 10. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001184858b 11. /build/src/IO/ReadWriteBufferFromHTTP.cpp:465: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x000000001184bf0b 12. /build/src/IO/ReadBuffer.h:60: DB::ReadBuffer::next() @ 0x000000000a148c7b 13. /build/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) @ 0x0000000011849fb2 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]>&)>&, 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&) @ 0x0000000011841980 15. /build/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) @ 0x000000001621208e 16. /build/src/Storages/StorageReplicatedMergeTree.cpp:5228: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl[abi:se190107] const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000015f9a5fe 17. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000015ed8bfd 18. /build/src/Storages/StorageReplicatedMergeTree.cpp:2514: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x0000000015ec9aab 19. /build/src/Storages/StorageReplicatedMergeTree.cpp:2349: DB::StorageReplicatedMergeTree::executeLogEntry(DB::ReplicatedMergeTreeLogEntry&) @ 0x0000000015eba91b 20. /build/src/Storages/StorageReplicatedMergeTree.cpp:3876: bool std::__function::__policy_invoker&)>::__call_impl[abi:se190107])::$_1, bool (std::shared_ptr&)>>(std::__function::__policy_storage const*, std::shared_ptr&) @ 0x0000000015f9837e 21. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000165d6fc3 22. /build/src/Storages/StorageReplicatedMergeTree.cpp:3872: DB::StorageReplicatedMergeTree::processQueueEntry(std::shared_ptr) @ 0x0000000015efc18a 23. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001624c1b2 24. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000162f9c70 25. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x00000000162fa55a 26. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc6653 27. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000000fccc4c3 28. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc3d92 29. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fcca080 30. ? @ 0x00007fbc6213eac3 31. ? @ 0x00007fbc621d0850 (version 25.3.6.10636.altinitytest (altinity build)) 2025.07.28 11:58:38.229532 [ 4900 ] {fc39b906-eeda-4c56-ab25-45a3d6bcb477} executeQuery: Code: 60. DB::Exception: Table test_15.concurrent_optimize_table does not exist. (UNKNOWN_TABLE) (version 25.3.6.10636.altinitytest (altinity build)) (from [::1]:38690) (comment: 01103_optimize_drop_race_zookeeper.sh) (query 1, line 1) (in query: INSERT INTO concurrent_optimize_table SELECT rand(1), rand(2), 1 / rand(3), toString(rand(4)), [rand(5), rand(6)], rand(7) % 2 ? NULL : generateUUIDv4(), (rand(8), rand(9)) FROM numbers(10000)), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000a06a8eb 4. /build/src/Databases/IDatabase.cpp:41: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x0000000013dd565f 5. /build/src/Interpreters/DatabaseCatalog.cpp:442: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x00000000144f0869 6. /build/src/Interpreters/DatabaseCatalog.cpp:976: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x00000000144f6c88 7. /build/src/Interpreters/InterpreterInsertQuery.cpp:169: DB::InterpreterInsertQuery::getTable(DB::ASTInsertQuery&) @ 0x000000001492bf04 8. /build/src/Interpreters/InterpreterInsertQuery.cpp:829: DB::InterpreterInsertQuery::execute() @ 0x0000000014933938 9. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88dc9 10. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 11. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 12. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 13. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 14. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 16. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 17. ? @ 0x00007fbc6213eac3 18. ? @ 0x00007fbc621d0850 2025.07.28 11:58:38.243259 [ 4900 ] {} TCPHandler: Code: 60. DB::Exception: Table test_15.concurrent_optimize_table does not exist. (UNKNOWN_TABLE), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000a06a8eb 4. /build/src/Databases/IDatabase.cpp:41: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x0000000013dd565f 5. /build/src/Interpreters/DatabaseCatalog.cpp:442: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x00000000144f0869 6. /build/src/Interpreters/DatabaseCatalog.cpp:976: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x00000000144f6c88 7. /build/src/Interpreters/InterpreterInsertQuery.cpp:169: DB::InterpreterInsertQuery::getTable(DB::ASTInsertQuery&) @ 0x000000001492bf04 8. /build/src/Interpreters/InterpreterInsertQuery.cpp:829: DB::InterpreterInsertQuery::execute() @ 0x0000000014933938 9. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88dc9 10. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 11. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 12. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 13. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 14. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 16. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 17. ? @ 0x00007fbc6213eac3 18. ? @ 0x00007fbc621d0850 2025.07.28 11:58:38.309262 [ 17191 ] {29b4c54b-a6b2-4c7a-b6e2-72b3387da3dc} executeQuery: Code: 60. DB::Exception: Table test_15.concurrent_optimize_table does not exist. (UNKNOWN_TABLE) (version 25.3.6.10636.altinitytest (altinity build)) (from [::1]:38726) (comment: 01103_optimize_drop_race_zookeeper.sh) (query 1, line 1) (in query: INSERT INTO concurrent_optimize_table SELECT rand(1), rand(2), 1 / rand(3), toString(rand(4)), [rand(5), rand(6)], rand(7) % 2 ? NULL : generateUUIDv4(), (rand(8), rand(9)) FROM numbers(10000)), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000a06a8eb 4. /build/src/Databases/IDatabase.cpp:41: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x0000000013dd565f 5. /build/src/Interpreters/DatabaseCatalog.cpp:442: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x00000000144f0869 6. /build/src/Interpreters/DatabaseCatalog.cpp:976: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x00000000144f6c88 7. /build/src/Interpreters/InterpreterInsertQuery.cpp:169: DB::InterpreterInsertQuery::getTable(DB::ASTInsertQuery&) @ 0x000000001492bf04 8. /build/src/Interpreters/InterpreterInsertQuery.cpp:829: DB::InterpreterInsertQuery::execute() @ 0x0000000014933938 9. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88dc9 10. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 11. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 12. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 13. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 14. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 16. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 17. ? @ 0x00007fbc6213eac3 18. ? @ 0x00007fbc621d0850 2025.07.28 11:58:38.315895 [ 17203 ] {f240d3cf-e08d-4a03-bffd-f9355f6c6524} executeQuery: Code: 60. DB::Exception: Table test_15.concurrent_optimize_table does not exist. (UNKNOWN_TABLE) (version 25.3.6.10636.altinitytest (altinity build)) (from [::1]:38746) (comment: 01103_optimize_drop_race_zookeeper.sh) (query 1, line 1) (in query: OPTIMIZE TABLE concurrent_optimize_table FINAL), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000a06a8eb 4. /build/src/Databases/IDatabase.cpp:41: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x0000000013dd565f 5. /build/src/Interpreters/DatabaseCatalog.cpp:442: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x00000000144f0869 6. /build/src/Interpreters/DatabaseCatalog.cpp:976: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x00000000144f6c88 7. /build/src/Interpreters/InterpreterOptimizeQuery.cpp:40: DB::InterpreterOptimizeQuery::execute() @ 0x0000000014cd71de 8. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88dc9 9. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 10. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 11. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 12. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 13. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 14. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 15. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 16. ? @ 0x00007fbc6213eac3 17. ? @ 0x00007fbc621d0850 2025.07.28 11:58:38.319305 [ 17255 ] {103280af-50c9-45c4-a042-f4bc0f575950} executeQuery: Code: 60. DB::Exception: Table test_15.concurrent_optimize_table does not exist. (UNKNOWN_TABLE) (version 25.3.6.10636.altinitytest (altinity build)) (from [::1]:38748) (comment: 01103_optimize_drop_race_zookeeper.sh) (query 1, line 1) (in query: OPTIMIZE TABLE concurrent_optimize_table FINAL), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000a06a8eb 4. /build/src/Databases/IDatabase.cpp:41: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x0000000013dd565f 5. /build/src/Interpreters/DatabaseCatalog.cpp:442: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x00000000144f0869 6. /build/src/Interpreters/DatabaseCatalog.cpp:976: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x00000000144f6c88 7. /build/src/Interpreters/InterpreterOptimizeQuery.cpp:40: DB::InterpreterOptimizeQuery::execute() @ 0x0000000014cd71de 8. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88dc9 9. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 10. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 11. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 12. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 13. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 14. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 15. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 16. ? @ 0x00007fbc6213eac3 17. ? @ 0x00007fbc621d0850 2025.07.28 11:58:38.337335 [ 17191 ] {} TCPHandler: Code: 60. DB::Exception: Table test_15.concurrent_optimize_table does not exist. (UNKNOWN_TABLE), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000a06a8eb 4. /build/src/Databases/IDatabase.cpp:41: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x0000000013dd565f 5. /build/src/Interpreters/DatabaseCatalog.cpp:442: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x00000000144f0869 6. /build/src/Interpreters/DatabaseCatalog.cpp:976: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x00000000144f6c88 7. /build/src/Interpreters/InterpreterInsertQuery.cpp:169: DB::InterpreterInsertQuery::getTable(DB::ASTInsertQuery&) @ 0x000000001492bf04 8. /build/src/Interpreters/InterpreterInsertQuery.cpp:829: DB::InterpreterInsertQuery::execute() @ 0x0000000014933938 9. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88dc9 10. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 11. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 12. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 13. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 14. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 16. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 17. ? @ 0x00007fbc6213eac3 18. ? @ 0x00007fbc621d0850 2025.07.28 11:58:38.353388 [ 4963 ] {61be36f9-a39e-4003-aabb-f2d141efa799} executeQuery: Code: 60. DB::Exception: Table test_15.concurrent_optimize_table does not exist. (UNKNOWN_TABLE) (version 25.3.6.10636.altinitytest (altinity build)) (from [::1]:38716) (comment: 01103_optimize_drop_race_zookeeper.sh) (query 1, line 1) (in query: OPTIMIZE TABLE concurrent_optimize_table FINAL), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000a06a8eb 4. /build/src/Databases/IDatabase.cpp:41: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x0000000013dd565f 5. /build/src/Interpreters/DatabaseCatalog.cpp:442: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x00000000144f0869 6. /build/src/Interpreters/DatabaseCatalog.cpp:976: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x00000000144f6c88 7. /build/src/Interpreters/InterpreterOptimizeQuery.cpp:40: DB::InterpreterOptimizeQuery::execute() @ 0x0000000014cd71de 8. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88dc9 9. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 10. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 11. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 12. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 13. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 14. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 15. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 16. ? @ 0x00007fbc6213eac3 17. ? @ 0x00007fbc621d0850 2025.07.28 11:58:38.364574 [ 17203 ] {} TCPHandler: Code: 60. DB::Exception: Table test_15.concurrent_optimize_table does not exist. (UNKNOWN_TABLE), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000a06a8eb 4. /build/src/Databases/IDatabase.cpp:41: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x0000000013dd565f 5. /build/src/Interpreters/DatabaseCatalog.cpp:442: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x00000000144f0869 6. /build/src/Interpreters/DatabaseCatalog.cpp:976: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x00000000144f6c88 7. /build/src/Interpreters/InterpreterOptimizeQuery.cpp:40: DB::InterpreterOptimizeQuery::execute() @ 0x0000000014cd71de 8. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88dc9 9. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 10. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 11. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 12. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 13. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 14. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 15. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 16. ? @ 0x00007fbc6213eac3 17. ? @ 0x00007fbc621d0850 2025.07.28 11:58:38.380115 [ 17557 ] {baea71f3-b334-44ce-9d8e-1da309cd5481} executeQuery: Code: 60. DB::Exception: Table test_15.concurrent_optimize_table does not exist. (UNKNOWN_TABLE) (version 25.3.6.10636.altinitytest (altinity build)) (from [::1]:38732) (comment: 01103_optimize_drop_race_zookeeper.sh) (query 1, line 1) (in query: INSERT INTO concurrent_optimize_table SELECT rand(1), rand(2), 1 / rand(3), toString(rand(4)), [rand(5), rand(6)], rand(7) % 2 ? NULL : generateUUIDv4(), (rand(8), rand(9)) FROM numbers(10000)), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000a06a8eb 4. /build/src/Databases/IDatabase.cpp:41: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x0000000013dd565f 5. /build/src/Interpreters/DatabaseCatalog.cpp:442: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x00000000144f0869 6. /build/src/Interpreters/DatabaseCatalog.cpp:976: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x00000000144f6c88 7. /build/src/Interpreters/InterpreterInsertQuery.cpp:169: DB::InterpreterInsertQuery::getTable(DB::ASTInsertQuery&) @ 0x000000001492bf04 8. /build/src/Interpreters/InterpreterInsertQuery.cpp:829: DB::InterpreterInsertQuery::execute() @ 0x0000000014933938 9. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88dc9 10. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 11. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 12. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 13. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 14. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 16. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 17. ? @ 0x00007fbc6213eac3 18. ? @ 0x00007fbc621d0850 2025.07.28 11:58:38.383658 [ 5747 ] {626db85f-e278-4d4b-be93-a5756848cafd} executeQuery: Code: 60. DB::Exception: Table test_15.concurrent_optimize_table does not exist. (UNKNOWN_TABLE) (version 25.3.6.10636.altinitytest (altinity build)) (from [::1]:38700) (comment: 01103_optimize_drop_race_zookeeper.sh) (query 1, line 1) (in query: INSERT INTO concurrent_optimize_table SELECT rand(1), rand(2), 1 / rand(3), toString(rand(4)), [rand(5), rand(6)], rand(7) % 2 ? NULL : generateUUIDv4(), (rand(8), rand(9)) FROM numbers(10000)), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000a06a8eb 4. /build/src/Databases/IDatabase.cpp:41: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x0000000013dd565f 5. /build/src/Interpreters/DatabaseCatalog.cpp:442: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x00000000144f0869 6. /build/src/Interpreters/DatabaseCatalog.cpp:976: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x00000000144f6c88 7. /build/src/Interpreters/InterpreterInsertQuery.cpp:169: DB::InterpreterInsertQuery::getTable(DB::ASTInsertQuery&) @ 0x000000001492bf04 8. /build/src/Interpreters/InterpreterInsertQuery.cpp:829: DB::InterpreterInsertQuery::execute() @ 0x0000000014933938 9. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88dc9 10. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 11. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 12. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 13. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 14. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 16. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 17. ? @ 0x00007fbc6213eac3 18. ? @ 0x00007fbc621d0850 2025.07.28 11:58:38.448587 [ 17255 ] {} TCPHandler: Code: 60. DB::Exception: Table test_15.concurrent_optimize_table does not exist. (UNKNOWN_TABLE), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000a06a8eb 4. /build/src/Databases/IDatabase.cpp:41: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x0000000013dd565f 5. /build/src/Interpreters/DatabaseCatalog.cpp:442: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x00000000144f0869 6. /build/src/Interpreters/DatabaseCatalog.cpp:976: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x00000000144f6c88 7. /build/src/Interpreters/InterpreterOptimizeQuery.cpp:40: DB::InterpreterOptimizeQuery::execute() @ 0x0000000014cd71de 8. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88dc9 9. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 10. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 11. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 12. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 13. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 14. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 15. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 16. ? @ 0x00007fbc6213eac3 17. ? @ 0x00007fbc621d0850 2025.07.28 11:58:38.455618 [ 4963 ] {} TCPHandler: Code: 60. DB::Exception: Table test_15.concurrent_optimize_table does not exist. (UNKNOWN_TABLE), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000a06a8eb 4. /build/src/Databases/IDatabase.cpp:41: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x0000000013dd565f 5. /build/src/Interpreters/DatabaseCatalog.cpp:442: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x00000000144f0869 6. /build/src/Interpreters/DatabaseCatalog.cpp:976: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x00000000144f6c88 7. /build/src/Interpreters/InterpreterOptimizeQuery.cpp:40: DB::InterpreterOptimizeQuery::execute() @ 0x0000000014cd71de 8. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88dc9 9. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 10. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 11. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 12. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 13. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 14. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 15. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 16. ? @ 0x00007fbc6213eac3 17. ? @ 0x00007fbc621d0850 2025.07.28 11:58:38.463872 [ 5747 ] {} TCPHandler: Code: 60. DB::Exception: Table test_15.concurrent_optimize_table does not exist. (UNKNOWN_TABLE), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000a06a8eb 4. /build/src/Databases/IDatabase.cpp:41: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x0000000013dd565f 5. /build/src/Interpreters/DatabaseCatalog.cpp:442: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x00000000144f0869 6. /build/src/Interpreters/DatabaseCatalog.cpp:976: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x00000000144f6c88 7. /build/src/Interpreters/InterpreterInsertQuery.cpp:169: DB::InterpreterInsertQuery::getTable(DB::ASTInsertQuery&) @ 0x000000001492bf04 8. /build/src/Interpreters/InterpreterInsertQuery.cpp:829: DB::InterpreterInsertQuery::execute() @ 0x0000000014933938 9. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88dc9 10. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 11. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 12. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 13. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 14. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 16. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 17. ? @ 0x00007fbc6213eac3 18. ? @ 0x00007fbc621d0850 2025.07.28 11:58:38.464437 [ 17557 ] {} TCPHandler: Code: 60. DB::Exception: Table test_15.concurrent_optimize_table does not exist. (UNKNOWN_TABLE), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000a06a8eb 4. /build/src/Databases/IDatabase.cpp:41: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x0000000013dd565f 5. /build/src/Interpreters/DatabaseCatalog.cpp:442: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x00000000144f0869 6. /build/src/Interpreters/DatabaseCatalog.cpp:976: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x00000000144f6c88 7. /build/src/Interpreters/InterpreterInsertQuery.cpp:169: DB::InterpreterInsertQuery::getTable(DB::ASTInsertQuery&) @ 0x000000001492bf04 8. /build/src/Interpreters/InterpreterInsertQuery.cpp:829: DB::InterpreterInsertQuery::execute() @ 0x0000000014933938 9. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88dc9 10. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 11. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 12. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 13. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 14. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 16. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 17. ? @ 0x00007fbc6213eac3 18. ? @ 0x00007fbc621d0850 2025.07.28 11:58:38.579882 [ 3971 ] {} test_13.rmt2 (7f9b740d-015c-470e-8cc6-8ba33be0dc63): auto DB::StorageReplicatedMergeTree::processQueueEntry(ReplicatedMergeTreeQueue::SelectedEntryPtr)::(anonymous class)::operator()(LogEntryPtr &) const: Code: 86. DB::HTTPException: Received error from remote server http://146b4357c08d:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Ftest%2F01165%2Ftest_13%2Frmt%2Freplicas%2F1&part=20250728_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.6.10636.altinitytest (altinity build)) '. (RECEIVED_ERROR_FROM_REMOTE_IO_SERVER), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.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 const&, int&&, String const&, unsigned long&&, String const&) @ 0x000000000feda8d9 4. /build/src/IO/HTTPCommon.cpp:104: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x000000000feda6e2 5. /build/src/IO/HTTPCommon.cpp:93: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x000000000feda537 6. /build/src/IO/ReadWriteBufferFromHTTP.cpp:277: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x000000001184a4c4 7. /build/src/IO/ReadWriteBufferFromHTTP.cpp:285: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x000000001184a615 8. /build/src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x000000001184ae59 9. /build/src/IO/ReadWriteBufferFromHTTP.cpp:472: void std::__function::__policy_invoker::__call_impl[abi:se190107]>(std::__function::__policy_storage const*) @ 0x000000001184cedd 10. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001184858b 11. /build/src/IO/ReadWriteBufferFromHTTP.cpp:465: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x000000001184bf0b 12. /build/src/IO/ReadBuffer.h:60: DB::ReadBuffer::next() @ 0x000000000a148c7b 13. /build/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) @ 0x0000000011849fb2 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]>&)>&, 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&) @ 0x0000000011841980 15. /build/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) @ 0x000000001621208e 16. /build/src/Storages/StorageReplicatedMergeTree.cpp:5228: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl[abi:se190107] const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000015f9a5fe 17. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000015ed8bfd 18. /build/src/Storages/StorageReplicatedMergeTree.cpp:2514: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x0000000015ec9aab 19. /build/src/Storages/StorageReplicatedMergeTree.cpp:2349: DB::StorageReplicatedMergeTree::executeLogEntry(DB::ReplicatedMergeTreeLogEntry&) @ 0x0000000015eba91b 20. /build/src/Storages/StorageReplicatedMergeTree.cpp:3876: bool std::__function::__policy_invoker&)>::__call_impl[abi:se190107])::$_1, bool (std::shared_ptr&)>>(std::__function::__policy_storage const*, std::shared_ptr&) @ 0x0000000015f9837e 21. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000165d6fc3 22. /build/src/Storages/StorageReplicatedMergeTree.cpp:3872: DB::StorageReplicatedMergeTree::processQueueEntry(std::shared_ptr) @ 0x0000000015efc18a 23. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001624c1b2 24. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000162f9c70 25. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x00000000162fa55a 26. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc6653 27. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000000fccc4c3 28. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc3d92 29. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fcca080 30. ? @ 0x00007fbc6213eac3 31. ? @ 0x00007fbc621d0850 (version 25.3.6.10636.altinitytest (altinity build)) 2025.07.28 11:58:38.600162 [ 17203 ] {2d01a07f-cd25-4daf-9905-c3e709a55fe1} executeQuery: Code: 60. DB::Exception: Table test_15.concurrent_optimize_table does not exist. (UNKNOWN_TABLE) (version 25.3.6.10636.altinitytest (altinity build)) (from [::1]:38764) (comment: 01103_optimize_drop_race_zookeeper.sh) (query 1, line 1) (in query: OPTIMIZE TABLE concurrent_optimize_table FINAL), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000a06a8eb 4. /build/src/Databases/IDatabase.cpp:41: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x0000000013dd565f 5. /build/src/Interpreters/DatabaseCatalog.cpp:442: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x00000000144f0869 6. /build/src/Interpreters/DatabaseCatalog.cpp:976: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x00000000144f6c88 7. /build/src/Interpreters/InterpreterOptimizeQuery.cpp:40: DB::InterpreterOptimizeQuery::execute() @ 0x0000000014cd71de 8. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88dc9 9. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 10. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 11. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 12. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 13. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 14. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 15. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 16. ? @ 0x00007fbc6213eac3 17. ? @ 0x00007fbc621d0850 2025.07.28 11:58:38.626835 [ 17203 ] {} TCPHandler: Code: 60. DB::Exception: Table test_15.concurrent_optimize_table does not exist. (UNKNOWN_TABLE), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000a06a8eb 4. /build/src/Databases/IDatabase.cpp:41: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x0000000013dd565f 5. /build/src/Interpreters/DatabaseCatalog.cpp:442: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x00000000144f0869 6. /build/src/Interpreters/DatabaseCatalog.cpp:976: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x00000000144f6c88 7. /build/src/Interpreters/InterpreterOptimizeQuery.cpp:40: DB::InterpreterOptimizeQuery::execute() @ 0x0000000014cd71de 8. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88dc9 9. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 10. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 11. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 12. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 13. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 14. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 15. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 16. ? @ 0x00007fbc6213eac3 17. ? @ 0x00007fbc621d0850 2025.07.28 11:58:38.647645 [ 3285 ] {7bdabb26-d955-434d-a70f-42f5baede17e} executeQuery: Code: 60. DB::Exception: Table test_15.concurrent_optimize_table does not exist. (UNKNOWN_TABLE) (version 25.3.6.10636.altinitytest (altinity build)) (from [::1]:38752) (comment: 01103_optimize_drop_race_zookeeper.sh) (query 1, line 1) (in query: INSERT INTO concurrent_optimize_table SELECT rand(1), rand(2), 1 / rand(3), toString(rand(4)), [rand(5), rand(6)], rand(7) % 2 ? NULL : generateUUIDv4(), (rand(8), rand(9)) FROM numbers(10000)), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000a06a8eb 4. /build/src/Databases/IDatabase.cpp:41: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x0000000013dd565f 5. /build/src/Interpreters/DatabaseCatalog.cpp:442: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x00000000144f0869 6. /build/src/Interpreters/DatabaseCatalog.cpp:976: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x00000000144f6c88 7. /build/src/Interpreters/InterpreterInsertQuery.cpp:169: DB::InterpreterInsertQuery::getTable(DB::ASTInsertQuery&) @ 0x000000001492bf04 8. /build/src/Interpreters/InterpreterInsertQuery.cpp:829: DB::InterpreterInsertQuery::execute() @ 0x0000000014933938 9. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88dc9 10. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 11. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 12. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 13. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 14. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 16. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 17. ? @ 0x00007fbc6213eac3 18. ? @ 0x00007fbc621d0850 2025.07.28 11:58:38.647814 [ 17191 ] {d7d33955-6596-4639-bd0c-38d2d881d5ba} executeQuery: Code: 60. DB::Exception: Table test_15.concurrent_optimize_table does not exist. (UNKNOWN_TABLE) (version 25.3.6.10636.altinitytest (altinity build)) (from [::1]:38774) (comment: 01103_optimize_drop_race_zookeeper.sh) (query 1, line 1) (in query: INSERT INTO concurrent_optimize_table SELECT rand(1), rand(2), 1 / rand(3), toString(rand(4)), [rand(5), rand(6)], rand(7) % 2 ? NULL : generateUUIDv4(), (rand(8), rand(9)) FROM numbers(10000)), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000a06a8eb 4. /build/src/Databases/IDatabase.cpp:41: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x0000000013dd565f 5. /build/src/Interpreters/DatabaseCatalog.cpp:442: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x00000000144f0869 6. /build/src/Interpreters/DatabaseCatalog.cpp:976: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x00000000144f6c88 7. /build/src/Interpreters/InterpreterInsertQuery.cpp:169: DB::InterpreterInsertQuery::getTable(DB::ASTInsertQuery&) @ 0x000000001492bf04 8. /build/src/Interpreters/InterpreterInsertQuery.cpp:829: DB::InterpreterInsertQuery::execute() @ 0x0000000014933938 9. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88dc9 10. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 11. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 12. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 13. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 14. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 16. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 17. ? @ 0x00007fbc6213eac3 18. ? @ 0x00007fbc621d0850 2025.07.28 11:58:38.666482 [ 3285 ] {} TCPHandler: Code: 60. DB::Exception: Table test_15.concurrent_optimize_table does not exist. (UNKNOWN_TABLE), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000a06a8eb 4. /build/src/Databases/IDatabase.cpp:41: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x0000000013dd565f 5. /build/src/Interpreters/DatabaseCatalog.cpp:442: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x00000000144f0869 6. /build/src/Interpreters/DatabaseCatalog.cpp:976: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x00000000144f6c88 7. /build/src/Interpreters/InterpreterInsertQuery.cpp:169: DB::InterpreterInsertQuery::getTable(DB::ASTInsertQuery&) @ 0x000000001492bf04 8. /build/src/Interpreters/InterpreterInsertQuery.cpp:829: DB::InterpreterInsertQuery::execute() @ 0x0000000014933938 9. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88dc9 10. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 11. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 12. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 13. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 14. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 16. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 17. ? @ 0x00007fbc6213eac3 18. ? @ 0x00007fbc621d0850 2025.07.28 11:58:38.725798 [ 5747 ] {2294708d-b29d-401d-ae27-0fba826957c9} executeQuery: Code: 60. DB::Exception: Table test_15.concurrent_optimize_table does not exist. (UNKNOWN_TABLE) (version 25.3.6.10636.altinitytest (altinity build)) (from [::1]:38780) (comment: 01103_optimize_drop_race_zookeeper.sh) (query 1, line 1) (in query: INSERT INTO concurrent_optimize_table SELECT rand(1), rand(2), 1 / rand(3), toString(rand(4)), [rand(5), rand(6)], rand(7) % 2 ? NULL : generateUUIDv4(), (rand(8), rand(9)) FROM numbers(10000)), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000a06a8eb 4. /build/src/Databases/IDatabase.cpp:41: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x0000000013dd565f 5. /build/src/Interpreters/DatabaseCatalog.cpp:442: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x00000000144f0869 6. /build/src/Interpreters/DatabaseCatalog.cpp:976: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x00000000144f6c88 7. /build/src/Interpreters/InterpreterInsertQuery.cpp:169: DB::InterpreterInsertQuery::getTable(DB::ASTInsertQuery&) @ 0x000000001492bf04 8. /build/src/Interpreters/InterpreterInsertQuery.cpp:829: DB::InterpreterInsertQuery::execute() @ 0x0000000014933938 9. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88dc9 10. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 11. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 12. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 13. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 14. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 16. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 17. ? @ 0x00007fbc6213eac3 18. ? @ 0x00007fbc621d0850 2025.07.28 11:58:38.760136 [ 5747 ] {} TCPHandler: Code: 60. DB::Exception: Table test_15.concurrent_optimize_table does not exist. (UNKNOWN_TABLE), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000a06a8eb 4. /build/src/Databases/IDatabase.cpp:41: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x0000000013dd565f 5. /build/src/Interpreters/DatabaseCatalog.cpp:442: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x00000000144f0869 6. /build/src/Interpreters/DatabaseCatalog.cpp:976: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x00000000144f6c88 7. /build/src/Interpreters/InterpreterInsertQuery.cpp:169: DB::InterpreterInsertQuery::getTable(DB::ASTInsertQuery&) @ 0x000000001492bf04 8. /build/src/Interpreters/InterpreterInsertQuery.cpp:829: DB::InterpreterInsertQuery::execute() @ 0x0000000014933938 9. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88dc9 10. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 11. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 12. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 13. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 14. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 16. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 17. ? @ 0x00007fbc6213eac3 18. ? @ 0x00007fbc621d0850 2025.07.28 11:58:38.796985 [ 17191 ] {} TCPHandler: Code: 60. DB::Exception: Table test_15.concurrent_optimize_table does not exist. (UNKNOWN_TABLE), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000a06a8eb 4. /build/src/Databases/IDatabase.cpp:41: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x0000000013dd565f 5. /build/src/Interpreters/DatabaseCatalog.cpp:442: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x00000000144f0869 6. /build/src/Interpreters/DatabaseCatalog.cpp:976: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x00000000144f6c88 7. /build/src/Interpreters/InterpreterInsertQuery.cpp:169: DB::InterpreterInsertQuery::getTable(DB::ASTInsertQuery&) @ 0x000000001492bf04 8. /build/src/Interpreters/InterpreterInsertQuery.cpp:829: DB::InterpreterInsertQuery::execute() @ 0x0000000014933938 9. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88dc9 10. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 11. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 12. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 13. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 14. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 16. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 17. ? @ 0x00007fbc6213eac3 18. ? @ 0x00007fbc621d0850 2025.07.28 11:58:38.800144 [ 4963 ] {edb7a852-d50b-4f6d-9fb0-f89879acc43d} executeQuery: Code: 60. DB::Exception: Table test_15.concurrent_optimize_table does not exist. (UNKNOWN_TABLE) (version 25.3.6.10636.altinitytest (altinity build)) (from [::1]:38794) (comment: 01103_optimize_drop_race_zookeeper.sh) (query 1, line 1) (in query: INSERT INTO concurrent_optimize_table SELECT rand(1), rand(2), 1 / rand(3), toString(rand(4)), [rand(5), rand(6)], rand(7) % 2 ? NULL : generateUUIDv4(), (rand(8), rand(9)) FROM numbers(10000)), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000a06a8eb 4. /build/src/Databases/IDatabase.cpp:41: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x0000000013dd565f 5. /build/src/Interpreters/DatabaseCatalog.cpp:442: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x00000000144f0869 6. /build/src/Interpreters/DatabaseCatalog.cpp:976: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x00000000144f6c88 7. /build/src/Interpreters/InterpreterInsertQuery.cpp:169: DB::InterpreterInsertQuery::getTable(DB::ASTInsertQuery&) @ 0x000000001492bf04 8. /build/src/Interpreters/InterpreterInsertQuery.cpp:829: DB::InterpreterInsertQuery::execute() @ 0x0000000014933938 9. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88dc9 10. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 11. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 12. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 13. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 14. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 16. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 17. ? @ 0x00007fbc6213eac3 18. ? @ 0x00007fbc621d0850 2025.07.28 11:58:38.819539 [ 4963 ] {} TCPHandler: Code: 60. DB::Exception: Table test_15.concurrent_optimize_table does not exist. (UNKNOWN_TABLE), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000a06a8eb 4. /build/src/Databases/IDatabase.cpp:41: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x0000000013dd565f 5. /build/src/Interpreters/DatabaseCatalog.cpp:442: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x00000000144f0869 6. /build/src/Interpreters/DatabaseCatalog.cpp:976: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x00000000144f6c88 7. /build/src/Interpreters/InterpreterInsertQuery.cpp:169: DB::InterpreterInsertQuery::getTable(DB::ASTInsertQuery&) @ 0x000000001492bf04 8. /build/src/Interpreters/InterpreterInsertQuery.cpp:829: DB::InterpreterInsertQuery::execute() @ 0x0000000014933938 9. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88dc9 10. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 11. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 12. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 13. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 14. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 16. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 17. ? @ 0x00007fbc6213eac3 18. ? @ 0x00007fbc621d0850 2025.07.28 11:58:38.953207 [ 4581 ] {27129321-3ed6-437f-bbe3-4258c813d8d8} executeQuery: Code: 60. DB::Exception: Table test_15.concurrent_optimize_table does not exist. (UNKNOWN_TABLE) (version 25.3.6.10636.altinitytest (altinity build)) (from [::1]:38846) (comment: 01103_optimize_drop_race_zookeeper.sh) (query 1, line 1) (in query: OPTIMIZE TABLE concurrent_optimize_table FINAL), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000a06a8eb 4. /build/src/Databases/IDatabase.cpp:41: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x0000000013dd565f 5. /build/src/Interpreters/DatabaseCatalog.cpp:442: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x00000000144f0869 6. /build/src/Interpreters/DatabaseCatalog.cpp:976: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x00000000144f6c88 7. /build/src/Interpreters/InterpreterOptimizeQuery.cpp:40: DB::InterpreterOptimizeQuery::execute() @ 0x0000000014cd71de 8. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88dc9 9. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 10. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 11. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 12. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 13. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 14. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 15. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 16. ? @ 0x00007fbc6213eac3 17. ? @ 0x00007fbc621d0850 2025.07.28 11:58:38.958020 [ 17255 ] {68f9450d-bee5-4499-8865-cc59d39e3dcc} executeQuery: Code: 60. DB::Exception: Table test_15.concurrent_optimize_table does not exist. (UNKNOWN_TABLE) (version 25.3.6.10636.altinitytest (altinity build)) (from [::1]:38828) (comment: 01103_optimize_drop_race_zookeeper.sh) (query 1, line 1) (in query: OPTIMIZE TABLE concurrent_optimize_table FINAL), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000a06a8eb 4. /build/src/Databases/IDatabase.cpp:41: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x0000000013dd565f 5. /build/src/Interpreters/DatabaseCatalog.cpp:442: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x00000000144f0869 6. /build/src/Interpreters/DatabaseCatalog.cpp:976: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x00000000144f6c88 7. /build/src/Interpreters/InterpreterOptimizeQuery.cpp:40: DB::InterpreterOptimizeQuery::execute() @ 0x0000000014cd71de 8. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88dc9 9. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 10. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 11. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 12. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 13. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 14. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 15. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 16. ? @ 0x00007fbc6213eac3 17. ? @ 0x00007fbc621d0850 2025.07.28 11:58:38.971855 [ 4581 ] {} TCPHandler: Code: 60. DB::Exception: Table test_15.concurrent_optimize_table does not exist. (UNKNOWN_TABLE), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000a06a8eb 4. /build/src/Databases/IDatabase.cpp:41: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x0000000013dd565f 5. /build/src/Interpreters/DatabaseCatalog.cpp:442: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x00000000144f0869 6. /build/src/Interpreters/DatabaseCatalog.cpp:976: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x00000000144f6c88 7. /build/src/Interpreters/InterpreterOptimizeQuery.cpp:40: DB::InterpreterOptimizeQuery::execute() @ 0x0000000014cd71de 8. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88dc9 9. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 10. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 11. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 12. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 13. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 14. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 15. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 16. ? @ 0x00007fbc6213eac3 17. ? @ 0x00007fbc621d0850 2025.07.28 11:58:38.983284 [ 17203 ] {2147efdd-579a-4bab-9ce3-f37d1ac5f8b8} executeQuery: Code: 60. DB::Exception: Table test_15.concurrent_optimize_table does not exist. (UNKNOWN_TABLE) (version 25.3.6.10636.altinitytest (altinity build)) (from [::1]:38814) (comment: 01103_optimize_drop_race_zookeeper.sh) (query 1, line 1) (in query: OPTIMIZE TABLE concurrent_optimize_table FINAL), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000a06a8eb 4. /build/src/Databases/IDatabase.cpp:41: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x0000000013dd565f 5. /build/src/Interpreters/DatabaseCatalog.cpp:442: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x00000000144f0869 6. /build/src/Interpreters/DatabaseCatalog.cpp:976: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x00000000144f6c88 7. /build/src/Interpreters/InterpreterOptimizeQuery.cpp:40: DB::InterpreterOptimizeQuery::execute() @ 0x0000000014cd71de 8. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88dc9 9. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 10. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 11. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 12. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 13. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 14. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 15. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 16. ? @ 0x00007fbc6213eac3 17. ? @ 0x00007fbc621d0850 2025.07.28 11:58:38.992064 [ 3285 ] {f7789a9d-68c1-4a5f-abb5-1d5e10d75522} executeQuery: Code: 60. DB::Exception: Table test_15.concurrent_optimize_table does not exist. (UNKNOWN_TABLE) (version 25.3.6.10636.altinitytest (altinity build)) (from [::1]:38830) (comment: 01103_optimize_drop_race_zookeeper.sh) (query 1, line 1) (in query: INSERT INTO concurrent_optimize_table SELECT rand(1), rand(2), 1 / rand(3), toString(rand(4)), [rand(5), rand(6)], rand(7) % 2 ? NULL : generateUUIDv4(), (rand(8), rand(9)) FROM numbers(10000)), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000a06a8eb 4. /build/src/Databases/IDatabase.cpp:41: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x0000000013dd565f 5. /build/src/Interpreters/DatabaseCatalog.cpp:442: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x00000000144f0869 6. /build/src/Interpreters/DatabaseCatalog.cpp:976: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x00000000144f6c88 7. /build/src/Interpreters/InterpreterInsertQuery.cpp:169: DB::InterpreterInsertQuery::getTable(DB::ASTInsertQuery&) @ 0x000000001492bf04 8. /build/src/Interpreters/InterpreterInsertQuery.cpp:829: DB::InterpreterInsertQuery::execute() @ 0x0000000014933938 9. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88dc9 10. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 11. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 12. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 13. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 14. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 16. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 17. ? @ 0x00007fbc6213eac3 18. ? @ 0x00007fbc621d0850 2025.07.28 11:58:39.005835 [ 17255 ] {} TCPHandler: Code: 60. DB::Exception: Table test_15.concurrent_optimize_table does not exist. (UNKNOWN_TABLE), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000a06a8eb 4. /build/src/Databases/IDatabase.cpp:41: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x0000000013dd565f 5. /build/src/Interpreters/DatabaseCatalog.cpp:442: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x00000000144f0869 6. /build/src/Interpreters/DatabaseCatalog.cpp:976: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x00000000144f6c88 7. /build/src/Interpreters/InterpreterOptimizeQuery.cpp:40: DB::InterpreterOptimizeQuery::execute() @ 0x0000000014cd71de 8. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88dc9 9. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 10. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 11. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 12. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 13. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 14. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 15. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 16. ? @ 0x00007fbc6213eac3 17. ? @ 0x00007fbc621d0850 2025.07.28 11:58:39.006494 [ 17203 ] {} TCPHandler: Code: 60. DB::Exception: Table test_15.concurrent_optimize_table does not exist. (UNKNOWN_TABLE), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000a06a8eb 4. /build/src/Databases/IDatabase.cpp:41: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x0000000013dd565f 5. /build/src/Interpreters/DatabaseCatalog.cpp:442: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x00000000144f0869 6. /build/src/Interpreters/DatabaseCatalog.cpp:976: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x00000000144f6c88 7. /build/src/Interpreters/InterpreterOptimizeQuery.cpp:40: DB::InterpreterOptimizeQuery::execute() @ 0x0000000014cd71de 8. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88dc9 9. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 10. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 11. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 12. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 13. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 14. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 15. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 16. ? @ 0x00007fbc6213eac3 17. ? @ 0x00007fbc621d0850 2025.07.28 11:58:39.027308 [ 3285 ] {} TCPHandler: Code: 60. DB::Exception: Table test_15.concurrent_optimize_table does not exist. (UNKNOWN_TABLE), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000a06a8eb 4. /build/src/Databases/IDatabase.cpp:41: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x0000000013dd565f 5. /build/src/Interpreters/DatabaseCatalog.cpp:442: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x00000000144f0869 6. /build/src/Interpreters/DatabaseCatalog.cpp:976: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x00000000144f6c88 7. /build/src/Interpreters/InterpreterInsertQuery.cpp:169: DB::InterpreterInsertQuery::getTable(DB::ASTInsertQuery&) @ 0x000000001492bf04 8. /build/src/Interpreters/InterpreterInsertQuery.cpp:829: DB::InterpreterInsertQuery::execute() @ 0x0000000014933938 9. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88dc9 10. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 11. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 12. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 13. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 14. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 16. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 17. ? @ 0x00007fbc6213eac3 18. ? @ 0x00007fbc621d0850 2025.07.28 11:58:39.069238 [ 17191 ] {e829a241-2631-47ab-87cc-eb59148ad815} executeQuery: Code: 60. DB::Exception: Table test_15.concurrent_optimize_table does not exist. (UNKNOWN_TABLE) (version 25.3.6.10636.altinitytest (altinity build)) (from [::1]:38870) (comment: 01103_optimize_drop_race_zookeeper.sh) (query 1, line 1) (in query: OPTIMIZE TABLE concurrent_optimize_table FINAL), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000a06a8eb 4. /build/src/Databases/IDatabase.cpp:41: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x0000000013dd565f 5. /build/src/Interpreters/DatabaseCatalog.cpp:442: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x00000000144f0869 6. /build/src/Interpreters/DatabaseCatalog.cpp:976: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x00000000144f6c88 7. /build/src/Interpreters/InterpreterOptimizeQuery.cpp:40: DB::InterpreterOptimizeQuery::execute() @ 0x0000000014cd71de 8. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88dc9 9. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 10. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 11. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 12. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 13. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 14. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 15. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 16. ? @ 0x00007fbc6213eac3 17. ? @ 0x00007fbc621d0850 2025.07.28 11:58:39.084470 [ 17191 ] {} TCPHandler: Code: 60. DB::Exception: Table test_15.concurrent_optimize_table does not exist. (UNKNOWN_TABLE), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000a06a8eb 4. /build/src/Databases/IDatabase.cpp:41: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x0000000013dd565f 5. /build/src/Interpreters/DatabaseCatalog.cpp:442: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x00000000144f0869 6. /build/src/Interpreters/DatabaseCatalog.cpp:976: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x00000000144f6c88 7. /build/src/Interpreters/InterpreterOptimizeQuery.cpp:40: DB::InterpreterOptimizeQuery::execute() @ 0x0000000014cd71de 8. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88dc9 9. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 10. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 11. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 12. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 13. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 14. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 15. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 16. ? @ 0x00007fbc6213eac3 17. ? @ 0x00007fbc621d0850 2025.07.28 11:58:39.210459 [ 7630 ] {aaca3848-72dd-4443-a44b-60279400507a} executeQuery: Code: 57. DB::Exception: Table test_15.concurrent_optimize_table already exists. (TABLE_ALREADY_EXISTS) (version 25.3.6.10636.altinitytest (altinity build)) (from [::1]:38674) (comment: 01103_optimize_drop_race_zookeeper.sh) (query 2, line 2) (in query: CREATE TABLE concurrent_optimize_table (`a` UInt8, `b` Int16, `c` Float32, `d` String, `e` Array(UInt8), `f` Nullable(UUID), `g` Tuple(UInt8, UInt16)) ENGINE = ReplicatedMergeTree('/clickhouse/tables/01103_optimize_drop_race_zookeeper_test_15/concurrent_optimize_table', '1') PARTITION BY b % 10 ORDER BY a SETTINGS old_parts_lifetime = 1, cleanup_delay_period = 0, cleanup_delay_period_random_add = 0, cleanup_thread_preferred_points_per_iteration = 0, index_granularity = 31489, 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 = 20868213, compact_parts_max_bytes_to_buffer = 108362629, compact_parts_max_granules_to_buffer = 1, compact_parts_merge_max_bytes_to_prefetch_part = 18898448, merge_max_block_size = 13220, prefer_fetch_merged_part_size_threshold = 1, vertical_merge_algorithm_min_rows_to_activate = 1000000, vertical_merge_algorithm_min_columns_to_activate = 76, min_merge_bytes_to_use_direct_io = 10737418240, index_granularity_bytes = 7046892, use_const_adaptive_granularity = false, 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 = true, cache_populated_by_fetch = false, marks_compress_block_size = 84392, primary_key_compress_block_size = 23861, 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. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000a06a8eb 4. /build/src/Interpreters/InterpreterCreateQuery.cpp:1824: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x0000000014901d53 5. /build/src/Interpreters/InterpreterCreateQuery.cpp:1743: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000148f9aa9 6. /build/src/Interpreters/InterpreterCreateQuery.cpp:2352: DB::InterpreterCreateQuery::execute() @ 0x0000000014905a41 7. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88dc9 8. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 9. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 10. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 11. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 12. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 13. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 14. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 15. ? @ 0x00007fbc6213eac3 16. ? @ 0x00007fbc621d0850 2025.07.28 11:58:39.211879 [ 11826 ] {a7a99e1c-df2a-4679-801e-404f3fbc64b7} executeQuery: Code: 57. DB::Exception: Table test_15.concurrent_optimize_table already exists. (TABLE_ALREADY_EXISTS) (version 25.3.6.10636.altinitytest (altinity build)) (from [::1]:38742) (comment: 01103_optimize_drop_race_zookeeper.sh) (query 2, line 2) (in query: CREATE TABLE concurrent_optimize_table (`a` UInt8, `b` Int16, `c` Float32, `d` String, `e` Array(UInt8), `f` Nullable(UUID), `g` Tuple(UInt8, UInt16)) ENGINE = ReplicatedMergeTree('/clickhouse/tables/01103_optimize_drop_race_zookeeper_test_15/concurrent_optimize_table', '1') PARTITION BY b % 10 ORDER BY a SETTINGS old_parts_lifetime = 1, cleanup_delay_period = 0, cleanup_delay_period_random_add = 0, cleanup_thread_preferred_points_per_iteration = 0, index_granularity = 31489, 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 = 20868213, compact_parts_max_bytes_to_buffer = 108362629, compact_parts_max_granules_to_buffer = 1, compact_parts_merge_max_bytes_to_prefetch_part = 18898448, merge_max_block_size = 13220, prefer_fetch_merged_part_size_threshold = 1, vertical_merge_algorithm_min_rows_to_activate = 1000000, vertical_merge_algorithm_min_columns_to_activate = 76, min_merge_bytes_to_use_direct_io = 10737418240, index_granularity_bytes = 7046892, use_const_adaptive_granularity = false, 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 = true, cache_populated_by_fetch = false, marks_compress_block_size = 84392, primary_key_compress_block_size = 23861, 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. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000a06a8eb 4. /build/src/Interpreters/InterpreterCreateQuery.cpp:1824: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x0000000014901d53 5. /build/src/Interpreters/InterpreterCreateQuery.cpp:1743: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000148f9aa9 6. /build/src/Interpreters/InterpreterCreateQuery.cpp:2352: DB::InterpreterCreateQuery::execute() @ 0x0000000014905a41 7. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88dc9 8. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 9. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 10. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 11. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 12. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 13. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 14. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 15. ? @ 0x00007fbc6213eac3 16. ? @ 0x00007fbc621d0850 2025.07.28 11:58:39.220190 [ 17321 ] {a3fc65bb-2696-4d93-a6c9-fdc9d1950fd5} executeQuery: Code: 57. DB::Exception: Table test_15.concurrent_optimize_table already exists. (TABLE_ALREADY_EXISTS) (version 25.3.6.10636.altinitytest (altinity build)) (from [::1]:38684) (comment: 01103_optimize_drop_race_zookeeper.sh) (query 2, line 2) (in query: CREATE TABLE concurrent_optimize_table (`a` UInt8, `b` Int16, `c` Float32, `d` String, `e` Array(UInt8), `f` Nullable(UUID), `g` Tuple(UInt8, UInt16)) ENGINE = ReplicatedMergeTree('/clickhouse/tables/01103_optimize_drop_race_zookeeper_test_15/concurrent_optimize_table', '1') PARTITION BY b % 10 ORDER BY a SETTINGS old_parts_lifetime = 1, cleanup_delay_period = 0, cleanup_delay_period_random_add = 0, cleanup_thread_preferred_points_per_iteration = 0, index_granularity = 31489, 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 = 20868213, compact_parts_max_bytes_to_buffer = 108362629, compact_parts_max_granules_to_buffer = 1, compact_parts_merge_max_bytes_to_prefetch_part = 18898448, merge_max_block_size = 13220, prefer_fetch_merged_part_size_threshold = 1, vertical_merge_algorithm_min_rows_to_activate = 1000000, vertical_merge_algorithm_min_columns_to_activate = 76, min_merge_bytes_to_use_direct_io = 10737418240, index_granularity_bytes = 7046892, use_const_adaptive_granularity = false, 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 = true, cache_populated_by_fetch = false, marks_compress_block_size = 84392, primary_key_compress_block_size = 23861, 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. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000a06a8eb 4. /build/src/Interpreters/InterpreterCreateQuery.cpp:1824: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x0000000014901d53 5. /build/src/Interpreters/InterpreterCreateQuery.cpp:1743: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000148f9aa9 6. /build/src/Interpreters/InterpreterCreateQuery.cpp:2352: DB::InterpreterCreateQuery::execute() @ 0x0000000014905a41 7. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88dc9 8. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 9. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 10. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 11. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 12. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 13. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 14. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 15. ? @ 0x00007fbc6213eac3 16. ? @ 0x00007fbc621d0850 2025.07.28 11:58:39.221681 [ 7630 ] {} TCPHandler: Code: 57. DB::Exception: Table test_15.concurrent_optimize_table already exists. (TABLE_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000a06a8eb 4. /build/src/Interpreters/InterpreterCreateQuery.cpp:1824: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x0000000014901d53 5. /build/src/Interpreters/InterpreterCreateQuery.cpp:1743: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000148f9aa9 6. /build/src/Interpreters/InterpreterCreateQuery.cpp:2352: DB::InterpreterCreateQuery::execute() @ 0x0000000014905a41 7. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88dc9 8. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 9. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 10. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 11. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 12. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 13. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 14. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 15. ? @ 0x00007fbc6213eac3 16. ? @ 0x00007fbc621d0850 2025.07.28 11:58:39.235661 [ 17321 ] {} TCPHandler: Code: 57. DB::Exception: Table test_15.concurrent_optimize_table already exists. (TABLE_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000a06a8eb 4. /build/src/Interpreters/InterpreterCreateQuery.cpp:1824: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x0000000014901d53 5. /build/src/Interpreters/InterpreterCreateQuery.cpp:1743: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000148f9aa9 6. /build/src/Interpreters/InterpreterCreateQuery.cpp:2352: DB::InterpreterCreateQuery::execute() @ 0x0000000014905a41 7. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88dc9 8. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 9. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 10. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 11. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 12. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 13. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 14. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 15. ? @ 0x00007fbc6213eac3 16. ? @ 0x00007fbc621d0850 2025.07.28 11:58:39.241556 [ 11826 ] {} TCPHandler: Code: 57. DB::Exception: Table test_15.concurrent_optimize_table already exists. (TABLE_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000a06a8eb 4. /build/src/Interpreters/InterpreterCreateQuery.cpp:1824: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x0000000014901d53 5. /build/src/Interpreters/InterpreterCreateQuery.cpp:1743: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000148f9aa9 6. /build/src/Interpreters/InterpreterCreateQuery.cpp:2352: DB::InterpreterCreateQuery::execute() @ 0x0000000014905a41 7. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88dc9 8. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 9. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 10. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 11. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 12. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 13. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 14. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 15. ? @ 0x00007fbc6213eac3 16. ? @ 0x00007fbc621d0850 2025.07.28 11:58:39.689839 [ 3967 ] {} test_13.rmt2 (7f9b740d-015c-470e-8cc6-8ba33be0dc63): auto DB::StorageReplicatedMergeTree::processQueueEntry(ReplicatedMergeTreeQueue::SelectedEntryPtr)::(anonymous class)::operator()(LogEntryPtr &) const: Code: 86. DB::HTTPException: Received error from remote server http://146b4357c08d:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Ftest%2F01165%2Ftest_13%2Frmt%2Freplicas%2F1&part=20250728_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.6.10636.altinitytest (altinity build)) '. (RECEIVED_ERROR_FROM_REMOTE_IO_SERVER), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.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 const&, int&&, String const&, unsigned long&&, String const&) @ 0x000000000feda8d9 4. /build/src/IO/HTTPCommon.cpp:104: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x000000000feda6e2 5. /build/src/IO/HTTPCommon.cpp:93: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x000000000feda537 6. /build/src/IO/ReadWriteBufferFromHTTP.cpp:277: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x000000001184a4c4 7. /build/src/IO/ReadWriteBufferFromHTTP.cpp:285: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x000000001184a615 8. /build/src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x000000001184ae59 9. /build/src/IO/ReadWriteBufferFromHTTP.cpp:472: void std::__function::__policy_invoker::__call_impl[abi:se190107]>(std::__function::__policy_storage const*) @ 0x000000001184cedd 10. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001184858b 11. /build/src/IO/ReadWriteBufferFromHTTP.cpp:465: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x000000001184bf0b 12. /build/src/IO/ReadBuffer.h:60: DB::ReadBuffer::next() @ 0x000000000a148c7b 13. /build/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) @ 0x0000000011849fb2 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]>&)>&, 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&) @ 0x0000000011841980 15. /build/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) @ 0x000000001621208e 16. /build/src/Storages/StorageReplicatedMergeTree.cpp:5228: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl[abi:se190107] const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000015f9a5fe 17. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000015ed8bfd 18. /build/src/Storages/StorageReplicatedMergeTree.cpp:2514: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x0000000015ec9aab 19. /build/src/Storages/StorageReplicatedMergeTree.cpp:2349: DB::StorageReplicatedMergeTree::executeLogEntry(DB::ReplicatedMergeTreeLogEntry&) @ 0x0000000015eba91b 20. /build/src/Storages/StorageReplicatedMergeTree.cpp:3876: bool std::__function::__policy_invoker&)>::__call_impl[abi:se190107])::$_1, bool (std::shared_ptr&)>>(std::__function::__policy_storage const*, std::shared_ptr&) @ 0x0000000015f9837e 21. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000165d6fc3 22. /build/src/Storages/StorageReplicatedMergeTree.cpp:3872: DB::StorageReplicatedMergeTree::processQueueEntry(std::shared_ptr) @ 0x0000000015efc18a 23. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001624c1b2 24. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000162f9c70 25. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x00000000162fa55a 26. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc6653 27. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000000fccc4c3 28. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc3d92 29. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fcca080 30. ? @ 0x00007fbc6213eac3 31. ? @ 0x00007fbc621d0850 (version 25.3.6.10636.altinitytest (altinity build)) 2025.07.28 11:58:40.248087 [ 17203 ] {d0810184-f008-44e9-975e-5cd2eeef9101} executeQuery: Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01103_optimize_drop_race_zookeeper_test_15/concurrent_optimize_table/replicas/1). (TABLE_IS_READ_ONLY) (version 25.3.6.10636.altinitytest (altinity build)) (from [::1]:38932) (comment: 01103_optimize_drop_race_zookeeper.sh) (query 1, line 1) (in query: OPTIMIZE TABLE concurrent_optimize_table FINAL), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000a9b78ab 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:5935: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000015e86144 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:329: DB::StorageReplicatedMergeTree::waitForProcessingQueue(unsigned long, DB::SyncReplicaMode, std::unordered_set, std::equal_to, std::allocator>) @ 0x0000000015f6fff9 6. /build/src/Storages/StorageReplicatedMergeTree.cpp:6230: DB::StorageReplicatedMergeTree::optimize(std::shared_ptr const&, std::shared_ptr const&, std::shared_ptr const&, bool, bool, std::vector> const&, bool, std::shared_ptr)::$_1::operator()(String const&) const @ 0x0000000015f23fb4 7. /build/src/Storages/StorageReplicatedMergeTree.cpp:6290: DB::StorageReplicatedMergeTree::optimize(std::shared_ptr const&, std::shared_ptr const&, std::shared_ptr const&, bool, bool, std::vector> const&, bool, std::shared_ptr) @ 0x0000000015f226cc 8. /build/src/Interpreters/InterpreterOptimizeQuery.cpp:84: DB::InterpreterOptimizeQuery::execute() @ 0x0000000014cd782e 9. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88dc9 10. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 11. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 12. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 13. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 14. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 16. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 17. ? @ 0x00007fbc6213eac3 18. ? @ 0x00007fbc621d0850 2025.07.28 11:58:40.275242 [ 3724 ] {} test_15.concurrent_optimize_table (9c945c27-e371-48cf-a0fa-281dbfe4419f): Removing temporary directory /var/lib/clickhouse/store/9c9/9c945c27-e371-48cf-a0fa-281dbfe4419f/tmp_insert_5_9_9_0/ 2025.07.28 11:58:40.282890 [ 17203 ] {} TCPHandler: Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01103_optimize_drop_race_zookeeper_test_15/concurrent_optimize_table/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000a9b78ab 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:5935: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000015e86144 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:329: DB::StorageReplicatedMergeTree::waitForProcessingQueue(unsigned long, DB::SyncReplicaMode, std::unordered_set, std::equal_to, std::allocator>) @ 0x0000000015f6fff9 6. /build/src/Storages/StorageReplicatedMergeTree.cpp:6230: DB::StorageReplicatedMergeTree::optimize(std::shared_ptr const&, std::shared_ptr const&, std::shared_ptr const&, bool, bool, std::vector> const&, bool, std::shared_ptr)::$_1::operator()(String const&) const @ 0x0000000015f23fb4 7. /build/src/Storages/StorageReplicatedMergeTree.cpp:6290: DB::StorageReplicatedMergeTree::optimize(std::shared_ptr const&, std::shared_ptr const&, std::shared_ptr const&, bool, bool, std::vector> const&, bool, std::shared_ptr) @ 0x0000000015f226cc 8. /build/src/Interpreters/InterpreterOptimizeQuery.cpp:84: DB::InterpreterOptimizeQuery::execute() @ 0x0000000014cd782e 9. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88dc9 10. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 11. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 12. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 13. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 14. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 16. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 17. ? @ 0x00007fbc6213eac3 18. ? @ 0x00007fbc621d0850 2025.07.28 11:58:40.357938 [ 5747 ] {0b224c10-43fd-4f42-a8ae-0f21f366a9e4} executeQuery: Code: 242. DB::Exception: Table is in readonly mode due to shutdown: replica_path=/clickhouse/tables/01103_optimize_drop_race_zookeeper_test_15/concurrent_optimize_table/replicas/1. (TABLE_IS_READ_ONLY) (version 25.3.6.10636.altinitytest (altinity build)) (from [::1]:38856) (comment: 01103_optimize_drop_race_zookeeper.sh) (query 1, line 1) (in query: INSERT INTO concurrent_optimize_table SELECT rand(1), rand(2), 1 / rand(3), toString(rand(4)), [rand(5), rand(6)], rand(7) % 2 ? NULL : generateUUIDv4(), (rand(8), rand(9)) FROM numbers(10000)), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000a9b78ab 4. /build/src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:866: DB::ReplicatedMergeTreeSinkImpl::commitPart(std::shared_ptr const&, std::shared_ptr&, String const&, unsigned long)::'lambda1'()::operator()() const @ 0x000000001660eed7 5. /build/src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:1124: DB::ReplicatedMergeTreeSinkImpl::commitPart(std::shared_ptr const&, std::shared_ptr&, String const&, unsigned long)::'lambda2'()::operator()() const @ 0x000000001660d1f2 6. /build/src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:1157: void DB::ZooKeeperRetriesControl::retryLoop::commitPart(std::shared_ptr const&, std::shared_ptr&, String const&, unsigned long)::'lambda3'()&, void DB::ZooKeeperRetriesControl::retryLoop::commitPart(std::shared_ptr const&, std::shared_ptr&, String const&, unsigned long)::'lambda3'()>(DB::ReplicatedMergeTreeSinkImpl::commitPart(std::shared_ptr const&, std::shared_ptr&, String const&, unsigned long)::'lambda3'()&&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::commitPart(std::shared_ptr const&, std::shared_ptr&, String const&, unsigned long)::'lambda3'()&&, void DB::ZooKeeperRetriesControl::retryLoop::commitPart(std::shared_ptr const&, std::shared_ptr&, String const&, unsigned long)::'lambda3'()>(DB::ReplicatedMergeTreeSinkImpl::commitPart(std::shared_ptr const&, std::shared_ptr&, String const&, unsigned long)::'lambda3'()&&)::'lambda'()&&) @ 0x000000001660d07f 7. /build/src/Common/ZooKeeper/ZooKeeperRetries.h:52: DB::ReplicatedMergeTreeSinkImpl::commitPart(std::shared_ptr const&, std::shared_ptr&, String const&, unsigned long) @ 0x00000000165fd951 8. /build/src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:492: DB::ReplicatedMergeTreeSinkImpl::finishDelayedChunk(std::shared_ptr const&) @ 0x00000000165f277d 9. /build/src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:437: DB::ReplicatedMergeTreeSinkImpl::consume(DB::Chunk&) @ 0x00000000165fbd00 10. /build/src/Processors/Sinks/SinkToStorage.cpp:10: DB::SinkToStorage::onConsume(DB::Chunk) @ 0x0000000016cee093 11. /build/src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: void std::__function::__policy_invoker::__call_impl[abi:se190107]>(std::__function::__policy_storage const*) @ 0x0000000016c0ad89 12. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000016c0abf5 13. /build/src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: DB::ExceptionKeepingTransform::work() @ 0x0000000016c0a6fe 14. /build/src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x00000000169bd00f 15. /build/src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x00000000169b2105 16. /build/src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeSingleThread(unsigned long) @ 0x00000000169b23be 17. /build/src/Processors/Executors/PipelineExecutor.cpp:416: void std::__function::__policy_invoker::__call_impl[abi:se190107]>(std::__function::__policy_storage const*) @ 0x00000000169b2e3f 18. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc6653 19. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000000fccc4c3 20. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc3d92 21. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fcca080 22. ? @ 0x00007fbc6213eac3 23. ? @ 0x00007fbc621d0850 2025.07.28 11:58:40.367940 [ 3972 ] {} test_13.rmt2 (7f9b740d-015c-470e-8cc6-8ba33be0dc63): auto DB::StorageReplicatedMergeTree::processQueueEntry(ReplicatedMergeTreeQueue::SelectedEntryPtr)::(anonymous class)::operator()(LogEntryPtr &) const: Code: 86. DB::HTTPException: Received error from remote server http://146b4357c08d:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Ftest%2F01165%2Ftest_13%2Frmt%2Freplicas%2F1&part=20250728_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.6.10636.altinitytest (altinity build)) '. (RECEIVED_ERROR_FROM_REMOTE_IO_SERVER), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.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 const&, int&&, String const&, unsigned long&&, String const&) @ 0x000000000feda8d9 4. /build/src/IO/HTTPCommon.cpp:104: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x000000000feda6e2 5. /build/src/IO/HTTPCommon.cpp:93: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x000000000feda537 6. /build/src/IO/ReadWriteBufferFromHTTP.cpp:277: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x000000001184a4c4 7. /build/src/IO/ReadWriteBufferFromHTTP.cpp:285: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x000000001184a615 8. /build/src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x000000001184ae59 9. /build/src/IO/ReadWriteBufferFromHTTP.cpp:472: void std::__function::__policy_invoker::__call_impl[abi:se190107]>(std::__function::__policy_storage const*) @ 0x000000001184cedd 10. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001184858b 11. /build/src/IO/ReadWriteBufferFromHTTP.cpp:465: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x000000001184bf0b 12. /build/src/IO/ReadBuffer.h:60: DB::ReadBuffer::next() @ 0x000000000a148c7b 13. /build/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) @ 0x0000000011849fb2 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]>&)>&, 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&) @ 0x0000000011841980 15. /build/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) @ 0x000000001621208e 16. /build/src/Storages/StorageReplicatedMergeTree.cpp:5228: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl[abi:se190107] const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000015f9a5fe 17. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000015ed8bfd 18. /build/src/Storages/StorageReplicatedMergeTree.cpp:2514: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x0000000015ec9aab 19. /build/src/Storages/StorageReplicatedMergeTree.cpp:2349: DB::StorageReplicatedMergeTree::executeLogEntry(DB::ReplicatedMergeTreeLogEntry&) @ 0x0000000015eba91b 20. /build/src/Storages/StorageReplicatedMergeTree.cpp:3876: bool std::__function::__policy_invoker&)>::__call_impl[abi:se190107])::$_1, bool (std::shared_ptr&)>>(std::__function::__policy_storage const*, std::shared_ptr&) @ 0x0000000015f9837e 21. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000165d6fc3 22. /build/src/Storages/StorageReplicatedMergeTree.cpp:3872: DB::StorageReplicatedMergeTree::processQueueEntry(std::shared_ptr) @ 0x0000000015efc18a 23. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001624c1b2 24. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000162f9c70 25. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x00000000162fa55a 26. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc6653 27. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000000fccc4c3 28. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc3d92 29. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fcca080 30. ? @ 0x00007fbc6213eac3 31. ? @ 0x00007fbc621d0850 (version 25.3.6.10636.altinitytest (altinity build)) 2025.07.28 11:58:40.391763 [ 5747 ] {} TCPHandler: Code: 242. DB::Exception: Table is in readonly mode due to shutdown: replica_path=/clickhouse/tables/01103_optimize_drop_race_zookeeper_test_15/concurrent_optimize_table/replicas/1. (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000a9b78ab 4. /build/src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:866: DB::ReplicatedMergeTreeSinkImpl::commitPart(std::shared_ptr const&, std::shared_ptr&, String const&, unsigned long)::'lambda1'()::operator()() const @ 0x000000001660eed7 5. /build/src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:1124: DB::ReplicatedMergeTreeSinkImpl::commitPart(std::shared_ptr const&, std::shared_ptr&, String const&, unsigned long)::'lambda2'()::operator()() const @ 0x000000001660d1f2 6. /build/src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:1157: void DB::ZooKeeperRetriesControl::retryLoop::commitPart(std::shared_ptr const&, std::shared_ptr&, String const&, unsigned long)::'lambda3'()&, void DB::ZooKeeperRetriesControl::retryLoop::commitPart(std::shared_ptr const&, std::shared_ptr&, String const&, unsigned long)::'lambda3'()>(DB::ReplicatedMergeTreeSinkImpl::commitPart(std::shared_ptr const&, std::shared_ptr&, String const&, unsigned long)::'lambda3'()&&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::commitPart(std::shared_ptr const&, std::shared_ptr&, String const&, unsigned long)::'lambda3'()&&, void DB::ZooKeeperRetriesControl::retryLoop::commitPart(std::shared_ptr const&, std::shared_ptr&, String const&, unsigned long)::'lambda3'()>(DB::ReplicatedMergeTreeSinkImpl::commitPart(std::shared_ptr const&, std::shared_ptr&, String const&, unsigned long)::'lambda3'()&&)::'lambda'()&&) @ 0x000000001660d07f 7. /build/src/Common/ZooKeeper/ZooKeeperRetries.h:52: DB::ReplicatedMergeTreeSinkImpl::commitPart(std::shared_ptr const&, std::shared_ptr&, String const&, unsigned long) @ 0x00000000165fd951 8. /build/src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:492: DB::ReplicatedMergeTreeSinkImpl::finishDelayedChunk(std::shared_ptr const&) @ 0x00000000165f277d 9. /build/src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:437: DB::ReplicatedMergeTreeSinkImpl::consume(DB::Chunk&) @ 0x00000000165fbd00 10. /build/src/Processors/Sinks/SinkToStorage.cpp:10: DB::SinkToStorage::onConsume(DB::Chunk) @ 0x0000000016cee093 11. /build/src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: void std::__function::__policy_invoker::__call_impl[abi:se190107]>(std::__function::__policy_storage const*) @ 0x0000000016c0ad89 12. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000016c0abf5 13. /build/src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: DB::ExceptionKeepingTransform::work() @ 0x0000000016c0a6fe 14. /build/src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x00000000169bd00f 15. /build/src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x00000000169b2105 16. /build/src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeSingleThread(unsigned long) @ 0x00000000169b23be 17. /build/src/Processors/Executors/PipelineExecutor.cpp:416: void std::__function::__policy_invoker::__call_impl[abi:se190107]>(std::__function::__policy_storage const*) @ 0x00000000169b2e3f 18. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc6653 19. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000000fccc4c3 20. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc3d92 21. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fcca080 22. ? @ 0x00007fbc6213eac3 23. ? @ 0x00007fbc621d0850 Job's origin stack trace: 0. /build/src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000000fc33b84 1. /build/src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000000fcc2ea7 2. /build/src/Common/ThreadPool.cpp:401: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fcc7f1c 3. /build/src/Common/ThreadPool.cpp:494: ThreadPoolImpl>::scheduleOrThrowOnError(std::function, Priority) @ 0x000000000fcc7a0e 4. /build/src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::spawnThreadsImpl() @ 0x00000000169b2c0c 5. /build/src/Processors/Executors/PipelineExecutor.cpp:394: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x00000000169b0ba7 6. /build/src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x00000000169b03f4 7. /build/src/Processors/Executors/CompletedPipelineExecutor.cpp:42: void std::__function::__policy_invoker::__call_impl[abi:se190107]::ThreadFromGlobalPoolImpl(DB::CompletedPipelineExecutor::execute()::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169af7e1 8. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc3d92 9. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fcca080 10. ? @ 0x00007fbc6213eac3 11. ? @ 0x00007fbc621d0850 Job's origin stack trace: 0. /build/src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000000fc33b84 1. /build/src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000000fcc2ea7 2. /build/src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fcc535c 3. /build/src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000000fcc584d 4. /build/src/Common/ThreadPool.h:279: DB::CompletedPipelineExecutor::execute() @ 0x00000000169af267 5. /build/src/Server/TCPHandler.cpp:707: DB::TCPHandler::runImpl() @ 0x00000000168e6b2e 6. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 7. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 8. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 9. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 10. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 11. ? @ 0x00007fbc6213eac3 12. ? @ 0x00007fbc621d0850 2025.07.28 11:58:40.487878 [ 7625 ] {c85a697b-3d1d-4034-9819-2694e9918299} executeQuery: Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01103_optimize_drop_race_zookeeper_test_15/concurrent_optimize_table/replicas/1). (TABLE_IS_READ_ONLY) (version 25.3.6.10636.altinitytest (altinity build)) (from [::1]:38978) (comment: 01103_optimize_drop_race_zookeeper.sh) (query 1, line 1) (in query: OPTIMIZE TABLE concurrent_optimize_table FINAL), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000a9b78ab 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:5935: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000015e86144 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:6112: DB::StorageReplicatedMergeTree::optimize(std::shared_ptr const&, std::shared_ptr const&, std::shared_ptr const&, bool, bool, std::vector> const&, bool, std::shared_ptr) @ 0x0000000015f21f2c 6. /build/src/Interpreters/InterpreterOptimizeQuery.cpp:84: DB::InterpreterOptimizeQuery::execute() @ 0x0000000014cd782e 7. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88dc9 8. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 9. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 10. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 11. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 12. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 13. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 14. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 15. ? @ 0x00007fbc6213eac3 16. ? @ 0x00007fbc621d0850 2025.07.28 11:58:40.499458 [ 7625 ] {} TCPHandler: Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01103_optimize_drop_race_zookeeper_test_15/concurrent_optimize_table/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000a9b78ab 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:5935: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000015e86144 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:6112: DB::StorageReplicatedMergeTree::optimize(std::shared_ptr const&, std::shared_ptr const&, std::shared_ptr const&, bool, bool, std::vector> const&, bool, std::shared_ptr) @ 0x0000000015f21f2c 6. /build/src/Interpreters/InterpreterOptimizeQuery.cpp:84: DB::InterpreterOptimizeQuery::execute() @ 0x0000000014cd782e 7. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88dc9 8. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 9. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 10. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 11. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 12. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 13. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 14. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 15. ? @ 0x00007fbc6213eac3 16. ? @ 0x00007fbc621d0850 2025.07.28 11:58:40.503910 [ 5880 ] {} 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. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: Coordination::Exception::Exception(T&&, Coordination::Error) @ 0x000000001660315b 3. /build/src/Common/ZooKeeper/KeeperException.h:58: Coordination::Exception Coordination::Exception::fromMessage(Coordination::Error, T&&) @ 0x00000000171a88d0 4. /build/src/Common/ZooKeeper/ZooKeeperImpl.cpp:1795: Coordination::ZooKeeper::maybeInjectRecvFault() @ 0x00000000171a20f1 5. /build/src/Common/ZooKeeper/ZooKeeperImpl.cpp:928: Coordination::ZooKeeper::receiveEvent() @ 0x00000000171a115e 6. /build/src/Common/ZooKeeper/ZooKeeperImpl.cpp:875: Coordination::ZooKeeper::receiveThread() @ 0x00000000171a0898 7. /build/src/Common/ZooKeeper/ZooKeeperImpl.cpp:452: void std::__function::__policy_invoker::__call_impl[abi:se190107]::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*) @ 0x00000000171a778a 8. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc3d92 9. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fcca080 10. ? @ 0x00007fbc6213eac3 11. ? @ 0x00007fbc621d0850 Job's origin stack trace: 0. /build/src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000000fc33b84 1. /build/src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000000fcc2ea7 2. /build/src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fcc535c 3. /build/src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000000fcc584d 4. /build/src/Common/ThreadPool.h:279: Coordination::ZooKeeper::ZooKeeper(std::vector> const&, zkutil::ZooKeeperArgs const&, std::shared_ptr) @ 0x00000000171993a4 5. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: zkutil::ZooKeeper::init(zkutil::ZooKeeperArgs, std::unique_ptr>) @ 0x0000000017139f9d 6. /build/src/Common/ZooKeeper/ZooKeeper.cpp:235: zkutil::ZooKeeper::ZooKeeper(zkutil::ZooKeeperArgs const&, std::shared_ptr, std::vector>, std::unique_ptr>) @ 0x000000001713cc06 7. /build/src/Common/ZooKeeper/ZooKeeper.cpp:1133: zkutil::ZooKeeper::startNewSession() const @ 0x0000000017147842 8. /build/src/Interpreters/Context.cpp:4043: DB::Context::getZooKeeper() const @ 0x000000001443fb0b 9. /build/src/Databases/DatabaseReplicated.cpp:111: DB::DatabaseReplicated::tryEnqueueReplicatedDDL(std::shared_ptr const&, std::shared_ptr, DB::QueryFlags) @ 0x0000000013d9f776 10. /build/src/Interpreters/InterpreterCreateQuery.cpp:1723: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000148f96f8 11. /build/src/Interpreters/InterpreterCreateQuery.cpp:2352: DB::InterpreterCreateQuery::execute() @ 0x0000000014905a41 12. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88dc9 13. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 14. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 15. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 16. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 17. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 18. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 19. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 20. ? @ 0x00007fbc6213eac3 21. ? @ 0x00007fbc621d0850 (version 25.3.6.10636.altinitytest (altinity build)) 2025.07.28 11:58:40.511992 [ 3434 ] {} test_3.test_03217_merge_replica_1 (ReplicatedMergeTreeRestartingThread): ZooKeeper session has expired. Switching to a new session. 2025.07.28 11:58:40.514576 [ 3782 ] {} test_13.rmt1 (ReplicatedMergeTreeRestartingThread): ZooKeeper session has expired. Switching to a new session. 2025.07.28 11:58:40.516142 [ 3405 ] {} test_1.t_json_3 (ReplicatedMergeTreeRestartingThread): ZooKeeper session has expired. Switching to a new session. 2025.07.28 11:58:40.517579 [ 3341 ] {} test_3.test_03217_merge_replica_2 (ReplicatedMergeTreeRestartingThread): ZooKeeper session has expired. Switching to a new session. 2025.07.28 11:58:40.518681 [ 3433 ] {} test_1.replicated_table_r1 (ReplicatedMergeTreeRestartingThread): ZooKeeper session has expired. Switching to a new session. 2025.07.28 11:58:40.521973 [ 3670 ] {} test_13.rmt2 (ReplicatedMergeTreeRestartingThread): ZooKeeper session has expired. Switching to a new session. 2025.07.28 11:58:40.523418 [ 3463 ] {} test_1.test_alter_decimal (ReplicatedMergeTreeRestartingThread): ZooKeeper session has expired. Switching to a new session. 2025.07.28 11:58:40.527390 [ 3668 ] {} test_1.replicated_table_r2 (ReplicatedMergeTreeRestartingThread): ZooKeeper session has expired. Switching to a new session. 2025.07.28 11:58:40.553642 [ 3763 ] {} rdb_test_y1ko7xdm.a (15fbd03e-8826-45a4-834c-92757e8739bb): void DB::StorageReplicatedMergeTree::mutationsUpdatingTask(): Code: 999. Coordination::Exception: Session expired. (KEEPER_EXCEPTION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: Coordination::Exception::Exception(T&&, Coordination::Error) @ 0x000000001716cf1b 3. /build/src/Common/ZooKeeper/KeeperException.h:58: Coordination::ZooKeeper::pushRequest(Coordination::ZooKeeper::RequestInfo&&) @ 0x00000000171a27b3 4. /build/src/Common/ZooKeeper/ZooKeeperImpl.cpp:1565: Coordination::ZooKeeper::list(String const&, Coordination::ListRequestType, std::function, std::shared_ptr>) @ 0x00000000171a61aa 5. /build/src/Common/ZooKeeper/ZooKeeper.cpp:1357: zkutil::ZooKeeper::asyncTryGetChildrenNoThrow(String const&, std::shared_ptr>, Coordination::ListRequestType) @ 0x000000001713d680 6. /build/src/Common/ZooKeeper/ZooKeeper.cpp:300: zkutil::ZooKeeper::getChildrenImpl(String const&, std::vector>&, Coordination::Stat*, std::shared_ptr>, Coordination::ListRequestType) @ 0x000000001713d1d5 7. /build/src/Common/ZooKeeper/ZooKeeper.cpp:374: zkutil::ZooKeeper::tryGetChildrenWatch(String const&, std::vector>&, Coordination::Stat*, std::shared_ptr>, Coordination::ListRequestType) @ 0x000000001713ddf2 8. /build/src/Common/ZooKeeper/ZooKeeper.cpp:336: zkutil::ZooKeeper::getChildrenWatch(String const&, Coordination::Stat*, std::shared_ptr>, Coordination::ListRequestType) @ 0x000000001713dd0b 9. /build/src/Storages/MergeTree/ReplicatedMergeTreeQueue.cpp:929: DB::ReplicatedMergeTreeQueue::updateMutations(std::shared_ptr, std::shared_ptr>) @ 0x00000000165c5226 10. /build/src/Storages/StorageReplicatedMergeTree.cpp:3833: DB::StorageReplicatedMergeTree::mutationsUpdatingTask() @ 0x0000000015efbe78 11. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000139630d4 12. /build/src/Core/BackgroundSchedulePool.cpp:308: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001396616a 13. /build/src/Core/BackgroundSchedulePool.cpp:171: void std::__function::__policy_invoker::__call_impl[abi:se190107]::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_1>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_1&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001396690a 14. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc3d92 15. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fcca080 16. ? @ 0x00007fbc6213eac3 17. ? @ 0x00007fbc621d0850 (version 25.3.6.10636.altinitytest (altinity build)) 2025.07.28 11:58:40.557941 [ 3557 ] {} test_di2z0wst.t1 (053a0213-db34-4647-9c84-8c2abadd9a60): void DB::StorageReplicatedMergeTree::mutationsUpdatingTask(): Code: 999. Coordination::Exception: Session expired. (KEEPER_EXCEPTION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: Coordination::Exception::Exception(T&&, Coordination::Error) @ 0x000000001716cf1b 3. /build/src/Common/ZooKeeper/KeeperException.h:58: Coordination::ZooKeeper::pushRequest(Coordination::ZooKeeper::RequestInfo&&) @ 0x00000000171a27b3 4. /build/src/Common/ZooKeeper/ZooKeeperImpl.cpp:1565: Coordination::ZooKeeper::list(String const&, Coordination::ListRequestType, std::function, std::shared_ptr>) @ 0x00000000171a61aa 5. /build/src/Common/ZooKeeper/ZooKeeper.cpp:1357: zkutil::ZooKeeper::asyncTryGetChildrenNoThrow(String const&, std::shared_ptr>, Coordination::ListRequestType) @ 0x000000001713d680 6. /build/src/Common/ZooKeeper/ZooKeeper.cpp:300: zkutil::ZooKeeper::getChildrenImpl(String const&, std::vector>&, Coordination::Stat*, std::shared_ptr>, Coordination::ListRequestType) @ 0x000000001713d1d5 7. /build/src/Common/ZooKeeper/ZooKeeper.cpp:374: zkutil::ZooKeeper::tryGetChildrenWatch(String const&, std::vector>&, Coordination::Stat*, std::shared_ptr>, Coordination::ListRequestType) @ 0x000000001713ddf2 8. /build/src/Common/ZooKeeper/ZooKeeper.cpp:336: zkutil::ZooKeeper::getChildrenWatch(String const&, Coordination::Stat*, std::shared_ptr>, Coordination::ListRequestType) @ 0x000000001713dd0b 9. /build/src/Storages/MergeTree/ReplicatedMergeTreeQueue.cpp:929: DB::ReplicatedMergeTreeQueue::updateMutations(std::shared_ptr, std::shared_ptr>) @ 0x00000000165c5226 10. /build/src/Storages/StorageReplicatedMergeTree.cpp:3833: DB::StorageReplicatedMergeTree::mutationsUpdatingTask() @ 0x0000000015efbe78 11. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000139630d4 12. /build/src/Core/BackgroundSchedulePool.cpp:308: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001396616a 13. /build/src/Core/BackgroundSchedulePool.cpp:171: void std::__function::__policy_invoker::__call_impl[abi:se190107]::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_1>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_1&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001396690a 14. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc3d92 15. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fcca080 16. ? @ 0x00007fbc6213eac3 17. ? @ 0x00007fbc621d0850 (version 25.3.6.10636.altinitytest (altinity build)) 2025.07.28 11:58:40.574767 [ 3285 ] {7d0dcf84-1b06-4c00-8af9-f6140c80d7cd} executeQuery: Code: 999. Coordination::Exception: Coordination error: Connection loss, path /clickhouse/tables/01103_optimize_drop_race_zookeeper_test_15/concurrent_optimize_table/log. (KEEPER_EXCEPTION) (version 25.3.6.10636.altinitytest (altinity build)) (from [::1]:38952) (comment: 01103_optimize_drop_race_zookeeper.sh) (query 1, line 1) (in query: OPTIMIZE TABLE concurrent_optimize_table FINAL), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, char const*&&, String const&) @ 0x000000000ba4e10b 4. /build/src/Common/ZooKeeper/KeeperException.h:37: Coordination::Exception::fromPath(Coordination::Error, String const&) @ 0x000000000ba4daab 5. /build/src/Common/ZooKeeper/ZooKeeper.cpp:696: zkutil::ZooKeeper::tryGetWatch(String const&, String&, Coordination::Stat*, std::function, Coordination::Error*) @ 0x0000000017141a56 6. /build/src/Common/ZooKeeper/ZooKeeper.cpp:664: zkutil::ZooKeeper::tryGet(String const&, String&, Coordination::Stat*, std::shared_ptr const&, Coordination::Error*) @ 0x0000000017141736 7. /build/src/Common/ZooKeeper/ZooKeeper.cpp:633: zkutil::ZooKeeper::get(String const&, Coordination::Stat*, std::shared_ptr const&) @ 0x0000000017141598 8. /build/src/Storages/MergeTree/ReplicatedMergeTreeQueue.cpp:645: DB::ReplicatedMergeTreeQueue::pullLogsToQueue(std::shared_ptr, std::function, DB::ReplicatedMergeTreeQueue::PullLogsReason) @ 0x00000000165c10f7 9. /build/src/Storages/MergeTree/Compaction/MergePredicates/ReplicatedMergeTreeMergePredicate.cpp:74: DB::ReplicatedMergeTreeZooKeeperMergePredicate::ReplicatedMergeTreeZooKeeperMergePredicate(DB::ReplicatedMergeTreeQueue&, std::shared_ptr&, std::optional, std::equal_to, std::allocator>>) @ 0x000000001667531f 10. /build/contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: DB::ReplicatedMergeTreeZooKeeperMergePredicate* std::construct_at[abi:se190107]&, std::optional, std::equal_to, std::allocator>>, DB::ReplicatedMergeTreeZooKeeperMergePredicate*>(DB::ReplicatedMergeTreeZooKeeperMergePredicate*, DB::ReplicatedMergeTreeQueue&, std::shared_ptr&, std::optional, std::equal_to, std::allocator>>&&) @ 0x00000000165e4c7a 11. /build/contrib/llvm-project/libcxx/include/__memory/construct_at.h:49: DB::ReplicatedMergeTreeQueue::getMergePredicate(std::shared_ptr&, std::optional, std::equal_to, std::allocator>>&&) @ 0x00000000165d736c 12. /build/src/Storages/StorageReplicatedMergeTree.cpp:6169: DB::StorageReplicatedMergeTree::optimize(std::shared_ptr const&, std::shared_ptr const&, std::shared_ptr const&, bool, bool, std::vector> const&, bool, std::shared_ptr)::$_1::operator()(String const&) const @ 0x0000000015f2386f 13. /build/src/Storages/StorageReplicatedMergeTree.cpp:6290: DB::StorageReplicatedMergeTree::optimize(std::shared_ptr const&, std::shared_ptr const&, std::shared_ptr const&, bool, bool, std::vector> const&, bool, std::shared_ptr) @ 0x0000000015f226cc 14. /build/src/Interpreters/InterpreterOptimizeQuery.cpp:84: DB::InterpreterOptimizeQuery::execute() @ 0x0000000014cd782e 15. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88dc9 16. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 17. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 18. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 19. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 20. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 21. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 22. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 23. ? @ 0x00007fbc6213eac3 24. ? @ 0x00007fbc621d0850 2025.07.28 11:58:40.581825 [ 17287 ] {97a4669d-11d8-4869-938b-001c4e1c6029} executeQuery: Code: 242. DB::Exception: Table is in readonly mode due to shutdown: replica_path=/clickhouse/tables/01103_optimize_drop_race_zookeeper_test_15/concurrent_optimize_table/replicas/1. (TABLE_IS_READ_ONLY) (version 25.3.6.10636.altinitytest (altinity build)) (from [::1]:38880) (comment: 01103_optimize_drop_race_zookeeper.sh) (query 1, line 1) (in query: INSERT INTO concurrent_optimize_table SELECT rand(1), rand(2), 1 / rand(3), toString(rand(4)), [rand(5), rand(6)], rand(7) % 2 ? NULL : generateUUIDv4(), (rand(8), rand(9)) FROM numbers(10000)), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000a9b78ab 4. /build/src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:866: DB::ReplicatedMergeTreeSinkImpl::commitPart(std::shared_ptr const&, std::shared_ptr&, String const&, unsigned long)::'lambda1'()::operator()() const @ 0x000000001660eed7 5. /build/src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:1124: DB::ReplicatedMergeTreeSinkImpl::commitPart(std::shared_ptr const&, std::shared_ptr&, String const&, unsigned long)::'lambda2'()::operator()() const @ 0x000000001660d1f2 6. /build/src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:1157: void DB::ZooKeeperRetriesControl::retryLoop::commitPart(std::shared_ptr const&, std::shared_ptr&, String const&, unsigned long)::'lambda3'()&, void DB::ZooKeeperRetriesControl::retryLoop::commitPart(std::shared_ptr const&, std::shared_ptr&, String const&, unsigned long)::'lambda3'()>(DB::ReplicatedMergeTreeSinkImpl::commitPart(std::shared_ptr const&, std::shared_ptr&, String const&, unsigned long)::'lambda3'()&&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::commitPart(std::shared_ptr const&, std::shared_ptr&, String const&, unsigned long)::'lambda3'()&&, void DB::ZooKeeperRetriesControl::retryLoop::commitPart(std::shared_ptr const&, std::shared_ptr&, String const&, unsigned long)::'lambda3'()>(DB::ReplicatedMergeTreeSinkImpl::commitPart(std::shared_ptr const&, std::shared_ptr&, String const&, unsigned long)::'lambda3'()&&)::'lambda'()&&) @ 0x000000001660d07f 7. /build/src/Common/ZooKeeper/ZooKeeperRetries.h:52: DB::ReplicatedMergeTreeSinkImpl::commitPart(std::shared_ptr const&, std::shared_ptr&, String const&, unsigned long) @ 0x00000000165fd951 8. /build/src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:492: DB::ReplicatedMergeTreeSinkImpl::finishDelayedChunk(std::shared_ptr const&) @ 0x00000000165f277d 9. /build/src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:437: DB::ReplicatedMergeTreeSinkImpl::consume(DB::Chunk&) @ 0x00000000165fbd00 10. /build/src/Processors/Sinks/SinkToStorage.cpp:10: DB::SinkToStorage::onConsume(DB::Chunk) @ 0x0000000016cee093 11. /build/src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: void std::__function::__policy_invoker::__call_impl[abi:se190107]>(std::__function::__policy_storage const*) @ 0x0000000016c0ad89 12. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000016c0abf5 13. /build/src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: DB::ExceptionKeepingTransform::work() @ 0x0000000016c0a6fe 14. /build/src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x00000000169bd00f 15. /build/src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x00000000169b2105 16. /build/src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeSingleThread(unsigned long) @ 0x00000000169b23be 17. /build/src/Processors/Executors/PipelineExecutor.cpp:416: void std::__function::__policy_invoker::__call_impl[abi:se190107]>(std::__function::__policy_storage const*) @ 0x00000000169b2e3f 18. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc6653 19. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000000fccc4c3 20. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc3d92 21. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fcca080 22. ? @ 0x00007fbc6213eac3 23. ? @ 0x00007fbc621d0850 2025.07.28 11:58:40.602027 [ 17255 ] {9c061e7f-3308-4454-8b54-1d8fe44449a0} executeQuery: Code: 999. Coordination::Exception: Session expired. (KEEPER_EXCEPTION) (version 25.3.6.10636.altinitytest (altinity build)) (from [::1]:38938) (comment: 01103_optimize_drop_race_zookeeper.sh) (query 1, line 1) (in query: OPTIMIZE TABLE concurrent_optimize_table FINAL), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: Coordination::Exception::Exception(T&&, Coordination::Error) @ 0x000000001716cf1b 3. /build/src/Common/ZooKeeper/KeeperException.h:58: Coordination::ZooKeeper::pushRequest(Coordination::ZooKeeper::RequestInfo&&) @ 0x00000000171a27b3 4. /build/src/Common/ZooKeeper/ZooKeeperImpl.cpp:1507: Coordination::ZooKeeper::get(String const&, std::function, std::shared_ptr>) @ 0x00000000171a573a 5. /build/src/Common/ZooKeeper/ZooKeeper.cpp:1258: zkutil::ZooKeeper::asyncTryGet(String const&) @ 0x000000001714890e 6. /build/src/Storages/MergeTree/Compaction/MergePredicates/ReplicatedMergeTreeMergePredicate.cpp:70: DB::ReplicatedMergeTreeZooKeeperMergePredicate::ReplicatedMergeTreeZooKeeperMergePredicate(DB::ReplicatedMergeTreeQueue&, std::shared_ptr&, std::optional, std::equal_to, std::allocator>>) @ 0x0000000016675071 7. /build/contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: DB::ReplicatedMergeTreeZooKeeperMergePredicate* std::construct_at[abi:se190107]&, std::optional, std::equal_to, std::allocator>>, DB::ReplicatedMergeTreeZooKeeperMergePredicate*>(DB::ReplicatedMergeTreeZooKeeperMergePredicate*, DB::ReplicatedMergeTreeQueue&, std::shared_ptr&, std::optional, std::equal_to, std::allocator>>&&) @ 0x00000000165e4c7a 8. /build/contrib/llvm-project/libcxx/include/__memory/construct_at.h:49: DB::ReplicatedMergeTreeQueue::getMergePredicate(std::shared_ptr&, std::optional, std::equal_to, std::allocator>>&&) @ 0x00000000165d736c 9. /build/src/Storages/StorageReplicatedMergeTree.cpp:6169: DB::StorageReplicatedMergeTree::optimize(std::shared_ptr const&, std::shared_ptr const&, std::shared_ptr const&, bool, bool, std::vector> const&, bool, std::shared_ptr)::$_1::operator()(String const&) const @ 0x0000000015f2386f 10. /build/src/Storages/StorageReplicatedMergeTree.cpp:6290: DB::StorageReplicatedMergeTree::optimize(std::shared_ptr const&, std::shared_ptr const&, std::shared_ptr const&, bool, bool, std::vector> const&, bool, std::shared_ptr) @ 0x0000000015f226cc 11. /build/src/Interpreters/InterpreterOptimizeQuery.cpp:84: DB::InterpreterOptimizeQuery::execute() @ 0x0000000014cd782e 12. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88dc9 13. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 14. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 15. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 16. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 17. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 18. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 19. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 20. ? @ 0x00007fbc6213eac3 21. ? @ 0x00007fbc621d0850 2025.07.28 11:58:40.613752 [ 4963 ] {fb85f85f-e246-40c7-9f3f-a03586bf7032} executeQuery: Code: 242. DB::Exception: Table is in readonly mode due to shutdown: replica_path=/clickhouse/tables/01103_optimize_drop_race_zookeeper_test_15/concurrent_optimize_table/replicas/1. (TABLE_IS_READ_ONLY) (version 25.3.6.10636.altinitytest (altinity build)) (from [::1]:38858) (comment: 01103_optimize_drop_race_zookeeper.sh) (query 1, line 1) (in query: INSERT INTO concurrent_optimize_table SELECT rand(1), rand(2), 1 / rand(3), toString(rand(4)), [rand(5), rand(6)], rand(7) % 2 ? NULL : generateUUIDv4(), (rand(8), rand(9)) FROM numbers(10000)), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000a9b78ab 4. /build/src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:866: DB::ReplicatedMergeTreeSinkImpl::commitPart(std::shared_ptr const&, std::shared_ptr&, String const&, unsigned long)::'lambda1'()::operator()() const @ 0x000000001660eed7 5. /build/src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:1124: DB::ReplicatedMergeTreeSinkImpl::commitPart(std::shared_ptr const&, std::shared_ptr&, String const&, unsigned long)::'lambda2'()::operator()() const @ 0x000000001660d1f2 6. /build/src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:1157: void DB::ZooKeeperRetriesControl::retryLoop::commitPart(std::shared_ptr const&, std::shared_ptr&, String const&, unsigned long)::'lambda3'()&, void DB::ZooKeeperRetriesControl::retryLoop::commitPart(std::shared_ptr const&, std::shared_ptr&, String const&, unsigned long)::'lambda3'()>(DB::ReplicatedMergeTreeSinkImpl::commitPart(std::shared_ptr const&, std::shared_ptr&, String const&, unsigned long)::'lambda3'()&&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::commitPart(std::shared_ptr const&, std::shared_ptr&, String const&, unsigned long)::'lambda3'()&&, void DB::ZooKeeperRetriesControl::retryLoop::commitPart(std::shared_ptr const&, std::shared_ptr&, String const&, unsigned long)::'lambda3'()>(DB::ReplicatedMergeTreeSinkImpl::commitPart(std::shared_ptr const&, std::shared_ptr&, String const&, unsigned long)::'lambda3'()&&)::'lambda'()&&) @ 0x000000001660d07f 7. /build/src/Common/ZooKeeper/ZooKeeperRetries.h:52: DB::ReplicatedMergeTreeSinkImpl::commitPart(std::shared_ptr const&, std::shared_ptr&, String const&, unsigned long) @ 0x00000000165fd951 8. /build/src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:492: DB::ReplicatedMergeTreeSinkImpl::finishDelayedChunk(std::shared_ptr const&) @ 0x00000000165f277d 9. /build/src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:437: DB::ReplicatedMergeTreeSinkImpl::consume(DB::Chunk&) @ 0x00000000165fbd00 10. /build/src/Processors/Sinks/SinkToStorage.cpp:10: DB::SinkToStorage::onConsume(DB::Chunk) @ 0x0000000016cee093 11. /build/src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: void std::__function::__policy_invoker::__call_impl[abi:se190107]>(std::__function::__policy_storage const*) @ 0x0000000016c0ad89 12. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000016c0abf5 13. /build/src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: DB::ExceptionKeepingTransform::work() @ 0x0000000016c0a6fe 14. /build/src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x00000000169bd00f 15. /build/src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x00000000169b2105 16. /build/src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeSingleThread(unsigned long) @ 0x00000000169b23be 17. /build/src/Processors/Executors/PipelineExecutor.cpp:416: void std::__function::__policy_invoker::__call_impl[abi:se190107]>(std::__function::__policy_storage const*) @ 0x00000000169b2e3f 18. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc6653 19. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000000fccc4c3 20. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc3d92 21. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fcca080 22. ? @ 0x00007fbc6213eac3 23. ? @ 0x00007fbc621d0850 2025.07.28 11:58:40.615171 [ 3285 ] {} TCPHandler: Code: 999. Coordination::Exception: Coordination error: Connection loss, path /clickhouse/tables/01103_optimize_drop_race_zookeeper_test_15/concurrent_optimize_table/log. (KEEPER_EXCEPTION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, char const*&&, String const&) @ 0x000000000ba4e10b 4. /build/src/Common/ZooKeeper/KeeperException.h:37: Coordination::Exception::fromPath(Coordination::Error, String const&) @ 0x000000000ba4daab 5. /build/src/Common/ZooKeeper/ZooKeeper.cpp:696: zkutil::ZooKeeper::tryGetWatch(String const&, String&, Coordination::Stat*, std::function, Coordination::Error*) @ 0x0000000017141a56 6. /build/src/Common/ZooKeeper/ZooKeeper.cpp:664: zkutil::ZooKeeper::tryGet(String const&, String&, Coordination::Stat*, std::shared_ptr const&, Coordination::Error*) @ 0x0000000017141736 7. /build/src/Common/ZooKeeper/ZooKeeper.cpp:633: zkutil::ZooKeeper::get(String const&, Coordination::Stat*, std::shared_ptr const&) @ 0x0000000017141598 8. /build/src/Storages/MergeTree/ReplicatedMergeTreeQueue.cpp:645: DB::ReplicatedMergeTreeQueue::pullLogsToQueue(std::shared_ptr, std::function, DB::ReplicatedMergeTreeQueue::PullLogsReason) @ 0x00000000165c10f7 9. /build/src/Storages/MergeTree/Compaction/MergePredicates/ReplicatedMergeTreeMergePredicate.cpp:74: DB::ReplicatedMergeTreeZooKeeperMergePredicate::ReplicatedMergeTreeZooKeeperMergePredicate(DB::ReplicatedMergeTreeQueue&, std::shared_ptr&, std::optional, std::equal_to, std::allocator>>) @ 0x000000001667531f 10. /build/contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: DB::ReplicatedMergeTreeZooKeeperMergePredicate* std::construct_at[abi:se190107]&, std::optional, std::equal_to, std::allocator>>, DB::ReplicatedMergeTreeZooKeeperMergePredicate*>(DB::ReplicatedMergeTreeZooKeeperMergePredicate*, DB::ReplicatedMergeTreeQueue&, std::shared_ptr&, std::optional, std::equal_to, std::allocator>>&&) @ 0x00000000165e4c7a 11. /build/contrib/llvm-project/libcxx/include/__memory/construct_at.h:49: DB::ReplicatedMergeTreeQueue::getMergePredicate(std::shared_ptr&, std::optional, std::equal_to, std::allocator>>&&) @ 0x00000000165d736c 12. /build/src/Storages/StorageReplicatedMergeTree.cpp:6169: DB::StorageReplicatedMergeTree::optimize(std::shared_ptr const&, std::shared_ptr const&, std::shared_ptr const&, bool, bool, std::vector> const&, bool, std::shared_ptr)::$_1::operator()(String const&) const @ 0x0000000015f2386f 13. /build/src/Storages/StorageReplicatedMergeTree.cpp:6290: DB::StorageReplicatedMergeTree::optimize(std::shared_ptr const&, std::shared_ptr const&, std::shared_ptr const&, bool, bool, std::vector> const&, bool, std::shared_ptr) @ 0x0000000015f226cc 14. /build/src/Interpreters/InterpreterOptimizeQuery.cpp:84: DB::InterpreterOptimizeQuery::execute() @ 0x0000000014cd782e 15. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88dc9 16. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 17. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 18. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 19. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 20. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 21. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 22. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 23. ? @ 0x00007fbc6213eac3 24. ? @ 0x00007fbc621d0850 2025.07.28 11:58:40.628285 [ 17255 ] {} TCPHandler: Code: 999. Coordination::Exception: Session expired. (KEEPER_EXCEPTION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: Coordination::Exception::Exception(T&&, Coordination::Error) @ 0x000000001716cf1b 3. /build/src/Common/ZooKeeper/KeeperException.h:58: Coordination::ZooKeeper::pushRequest(Coordination::ZooKeeper::RequestInfo&&) @ 0x00000000171a27b3 4. /build/src/Common/ZooKeeper/ZooKeeperImpl.cpp:1507: Coordination::ZooKeeper::get(String const&, std::function, std::shared_ptr>) @ 0x00000000171a573a 5. /build/src/Common/ZooKeeper/ZooKeeper.cpp:1258: zkutil::ZooKeeper::asyncTryGet(String const&) @ 0x000000001714890e 6. /build/src/Storages/MergeTree/Compaction/MergePredicates/ReplicatedMergeTreeMergePredicate.cpp:70: DB::ReplicatedMergeTreeZooKeeperMergePredicate::ReplicatedMergeTreeZooKeeperMergePredicate(DB::ReplicatedMergeTreeQueue&, std::shared_ptr&, std::optional, std::equal_to, std::allocator>>) @ 0x0000000016675071 7. /build/contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: DB::ReplicatedMergeTreeZooKeeperMergePredicate* std::construct_at[abi:se190107]&, std::optional, std::equal_to, std::allocator>>, DB::ReplicatedMergeTreeZooKeeperMergePredicate*>(DB::ReplicatedMergeTreeZooKeeperMergePredicate*, DB::ReplicatedMergeTreeQueue&, std::shared_ptr&, std::optional, std::equal_to, std::allocator>>&&) @ 0x00000000165e4c7a 8. /build/contrib/llvm-project/libcxx/include/__memory/construct_at.h:49: DB::ReplicatedMergeTreeQueue::getMergePredicate(std::shared_ptr&, std::optional, std::equal_to, std::allocator>>&&) @ 0x00000000165d736c 9. /build/src/Storages/StorageReplicatedMergeTree.cpp:6169: DB::StorageReplicatedMergeTree::optimize(std::shared_ptr const&, std::shared_ptr const&, std::shared_ptr const&, bool, bool, std::vector> const&, bool, std::shared_ptr)::$_1::operator()(String const&) const @ 0x0000000015f2386f 10. /build/src/Storages/StorageReplicatedMergeTree.cpp:6290: DB::StorageReplicatedMergeTree::optimize(std::shared_ptr const&, std::shared_ptr const&, std::shared_ptr const&, bool, bool, std::vector> const&, bool, std::shared_ptr) @ 0x0000000015f226cc 11. /build/src/Interpreters/InterpreterOptimizeQuery.cpp:84: DB::InterpreterOptimizeQuery::execute() @ 0x0000000014cd782e 12. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88dc9 13. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 14. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 15. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 16. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 17. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 18. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 19. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 20. ? @ 0x00007fbc6213eac3 21. ? @ 0x00007fbc621d0850 2025.07.28 11:58:40.637250 [ 17287 ] {} TCPHandler: Code: 242. DB::Exception: Table is in readonly mode due to shutdown: replica_path=/clickhouse/tables/01103_optimize_drop_race_zookeeper_test_15/concurrent_optimize_table/replicas/1. (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000a9b78ab 4. /build/src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:866: DB::ReplicatedMergeTreeSinkImpl::commitPart(std::shared_ptr const&, std::shared_ptr&, String const&, unsigned long)::'lambda1'()::operator()() const @ 0x000000001660eed7 5. /build/src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:1124: DB::ReplicatedMergeTreeSinkImpl::commitPart(std::shared_ptr const&, std::shared_ptr&, String const&, unsigned long)::'lambda2'()::operator()() const @ 0x000000001660d1f2 6. /build/src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:1157: void DB::ZooKeeperRetriesControl::retryLoop::commitPart(std::shared_ptr const&, std::shared_ptr&, String const&, unsigned long)::'lambda3'()&, void DB::ZooKeeperRetriesControl::retryLoop::commitPart(std::shared_ptr const&, std::shared_ptr&, String const&, unsigned long)::'lambda3'()>(DB::ReplicatedMergeTreeSinkImpl::commitPart(std::shared_ptr const&, std::shared_ptr&, String const&, unsigned long)::'lambda3'()&&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::commitPart(std::shared_ptr const&, std::shared_ptr&, String const&, unsigned long)::'lambda3'()&&, void DB::ZooKeeperRetriesControl::retryLoop::commitPart(std::shared_ptr const&, std::shared_ptr&, String const&, unsigned long)::'lambda3'()>(DB::ReplicatedMergeTreeSinkImpl::commitPart(std::shared_ptr const&, std::shared_ptr&, String const&, unsigned long)::'lambda3'()&&)::'lambda'()&&) @ 0x000000001660d07f 7. /build/src/Common/ZooKeeper/ZooKeeperRetries.h:52: DB::ReplicatedMergeTreeSinkImpl::commitPart(std::shared_ptr const&, std::shared_ptr&, String const&, unsigned long) @ 0x00000000165fd951 8. /build/src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:492: DB::ReplicatedMergeTreeSinkImpl::finishDelayedChunk(std::shared_ptr const&) @ 0x00000000165f277d 9. /build/src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:437: DB::ReplicatedMergeTreeSinkImpl::consume(DB::Chunk&) @ 0x00000000165fbd00 10. /build/src/Processors/Sinks/SinkToStorage.cpp:10: DB::SinkToStorage::onConsume(DB::Chunk) @ 0x0000000016cee093 11. /build/src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: void std::__function::__policy_invoker::__call_impl[abi:se190107]>(std::__function::__policy_storage const*) @ 0x0000000016c0ad89 12. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000016c0abf5 13. /build/src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: DB::ExceptionKeepingTransform::work() @ 0x0000000016c0a6fe 14. /build/src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x00000000169bd00f 15. /build/src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x00000000169b2105 16. /build/src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeSingleThread(unsigned long) @ 0x00000000169b23be 17. /build/src/Processors/Executors/PipelineExecutor.cpp:416: void std::__function::__policy_invoker::__call_impl[abi:se190107]>(std::__function::__policy_storage const*) @ 0x00000000169b2e3f 18. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc6653 19. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000000fccc4c3 20. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc3d92 21. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fcca080 22. ? @ 0x00007fbc6213eac3 23. ? @ 0x00007fbc621d0850 Job's origin stack trace: 0. /build/src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000000fc33b84 1. /build/src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000000fcc2ea7 2. /build/src/Common/ThreadPool.cpp:401: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fcc7f1c 3. /build/src/Common/ThreadPool.cpp:494: ThreadPoolImpl>::scheduleOrThrowOnError(std::function, Priority) @ 0x000000000fcc7a0e 4. /build/src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::spawnThreadsImpl() @ 0x00000000169b2c0c 5. /build/src/Processors/Executors/PipelineExecutor.cpp:394: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x00000000169b0ba7 6. /build/src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x00000000169b03f4 7. /build/src/Processors/Executors/CompletedPipelineExecutor.cpp:42: void std::__function::__policy_invoker::__call_impl[abi:se190107]::ThreadFromGlobalPoolImpl(DB::CompletedPipelineExecutor::execute()::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169af7e1 8. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc3d92 9. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fcca080 10. ? @ 0x00007fbc6213eac3 11. ? @ 0x00007fbc621d0850 Job's origin stack trace: 0. /build/src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000000fc33b84 1. /build/src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000000fcc2ea7 2. /build/src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fcc535c 3. /build/src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000000fcc584d 4. /build/src/Common/ThreadPool.h:279: DB::CompletedPipelineExecutor::execute() @ 0x00000000169af267 5. /build/src/Server/TCPHandler.cpp:707: DB::TCPHandler::runImpl() @ 0x00000000168e6b2e 6. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 7. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 8. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 9. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 10. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 11. ? @ 0x00007fbc6213eac3 12. ? @ 0x00007fbc621d0850 2025.07.28 11:58:40.652458 [ 4963 ] {} TCPHandler: Code: 242. DB::Exception: Table is in readonly mode due to shutdown: replica_path=/clickhouse/tables/01103_optimize_drop_race_zookeeper_test_15/concurrent_optimize_table/replicas/1. (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000a9b78ab 4. /build/src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:866: DB::ReplicatedMergeTreeSinkImpl::commitPart(std::shared_ptr const&, std::shared_ptr&, String const&, unsigned long)::'lambda1'()::operator()() const @ 0x000000001660eed7 5. /build/src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:1124: DB::ReplicatedMergeTreeSinkImpl::commitPart(std::shared_ptr const&, std::shared_ptr&, String const&, unsigned long)::'lambda2'()::operator()() const @ 0x000000001660d1f2 6. /build/src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:1157: void DB::ZooKeeperRetriesControl::retryLoop::commitPart(std::shared_ptr const&, std::shared_ptr&, String const&, unsigned long)::'lambda3'()&, void DB::ZooKeeperRetriesControl::retryLoop::commitPart(std::shared_ptr const&, std::shared_ptr&, String const&, unsigned long)::'lambda3'()>(DB::ReplicatedMergeTreeSinkImpl::commitPart(std::shared_ptr const&, std::shared_ptr&, String const&, unsigned long)::'lambda3'()&&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::commitPart(std::shared_ptr const&, std::shared_ptr&, String const&, unsigned long)::'lambda3'()&&, void DB::ZooKeeperRetriesControl::retryLoop::commitPart(std::shared_ptr const&, std::shared_ptr&, String const&, unsigned long)::'lambda3'()>(DB::ReplicatedMergeTreeSinkImpl::commitPart(std::shared_ptr const&, std::shared_ptr&, String const&, unsigned long)::'lambda3'()&&)::'lambda'()&&) @ 0x000000001660d07f 7. /build/src/Common/ZooKeeper/ZooKeeperRetries.h:52: DB::ReplicatedMergeTreeSinkImpl::commitPart(std::shared_ptr const&, std::shared_ptr&, String const&, unsigned long) @ 0x00000000165fd951 8. /build/src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:492: DB::ReplicatedMergeTreeSinkImpl::finishDelayedChunk(std::shared_ptr const&) @ 0x00000000165f277d 9. /build/src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:437: DB::ReplicatedMergeTreeSinkImpl::consume(DB::Chunk&) @ 0x00000000165fbd00 10. /build/src/Processors/Sinks/SinkToStorage.cpp:10: DB::SinkToStorage::onConsume(DB::Chunk) @ 0x0000000016cee093 11. /build/src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: void std::__function::__policy_invoker::__call_impl[abi:se190107]>(std::__function::__policy_storage const*) @ 0x0000000016c0ad89 12. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000016c0abf5 13. /build/src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: DB::ExceptionKeepingTransform::work() @ 0x0000000016c0a6fe 14. /build/src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x00000000169bd00f 15. /build/src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x00000000169b2105 16. /build/src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeSingleThread(unsigned long) @ 0x00000000169b23be 17. /build/src/Processors/Executors/PipelineExecutor.cpp:416: void std::__function::__policy_invoker::__call_impl[abi:se190107]>(std::__function::__policy_storage const*) @ 0x00000000169b2e3f 18. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc6653 19. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000000fccc4c3 20. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc3d92 21. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fcca080 22. ? @ 0x00007fbc6213eac3 23. ? @ 0x00007fbc621d0850 Job's origin stack trace: 0. /build/src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000000fc33b84 1. /build/src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000000fcc2ea7 2. /build/src/Common/ThreadPool.cpp:401: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fcc7f1c 3. /build/src/Common/ThreadPool.cpp:494: ThreadPoolImpl>::scheduleOrThrowOnError(std::function, Priority) @ 0x000000000fcc7a0e 4. /build/src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::spawnThreadsImpl() @ 0x00000000169b2c0c 5. /build/src/Processors/Executors/PipelineExecutor.cpp:394: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x00000000169b0ba7 6. /build/src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x00000000169b03f4 7. /build/src/Processors/Executors/CompletedPipelineExecutor.cpp:42: void std::__function::__policy_invoker::__call_impl[abi:se190107]::ThreadFromGlobalPoolImpl(DB::CompletedPipelineExecutor::execute()::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169af7e1 8. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc3d92 9. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fcca080 10. ? @ 0x00007fbc6213eac3 11. ? @ 0x00007fbc621d0850 Job's origin stack trace: 0. /build/src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000000fc33b84 1. /build/src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000000fcc2ea7 2. /build/src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fcc535c 3. /build/src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000000fcc584d 4. /build/src/Common/ThreadPool.h:279: DB::CompletedPipelineExecutor::execute() @ 0x00000000169af267 5. /build/src/Server/TCPHandler.cpp:707: DB::TCPHandler::runImpl() @ 0x00000000168e6b2e 6. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 7. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 8. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 9. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 10. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 11. ? @ 0x00007fbc6213eac3 12. ? @ 0x00007fbc621d0850 2025.07.28 11:58:40.658505 [ 4446 ] {a1991b3e-59b5-4b6e-b6e1-6230e79e9284} executeQuery: Code: 60. DB::Exception: Table test_15.concurrent_optimize_table does not exist. (UNKNOWN_TABLE) (version 25.3.6.10636.altinitytest (altinity build)) (from [::1]:38996) (comment: 01103_optimize_drop_race_zookeeper.sh) (query 1, line 1) (in query: INSERT INTO concurrent_optimize_table SELECT rand(1), rand(2), 1 / rand(3), toString(rand(4)), [rand(5), rand(6)], rand(7) % 2 ? NULL : generateUUIDv4(), (rand(8), rand(9)) FROM numbers(10000)), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000a06a8eb 4. /build/src/Databases/IDatabase.cpp:41: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x0000000013dd565f 5. /build/src/Interpreters/DatabaseCatalog.cpp:442: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x00000000144f0869 6. /build/src/Interpreters/DatabaseCatalog.cpp:976: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x00000000144f6c88 7. /build/src/Interpreters/InterpreterInsertQuery.cpp:169: DB::InterpreterInsertQuery::getTable(DB::ASTInsertQuery&) @ 0x000000001492bf04 8. /build/src/Interpreters/InterpreterInsertQuery.cpp:829: DB::InterpreterInsertQuery::execute() @ 0x0000000014933938 9. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88dc9 10. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 11. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 12. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 13. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 14. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 16. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 17. ? @ 0x00007fbc6213eac3 18. ? @ 0x00007fbc621d0850 2025.07.28 11:58:40.672734 [ 17191 ] {266a7b51-079a-43c3-9dd6-6e1004620229} executeQuery: Code: 242. DB::Exception: Table is in readonly mode due to shutdown: replica_path=/clickhouse/tables/01103_optimize_drop_race_zookeeper_test_15/concurrent_optimize_table/replicas/1. (TABLE_IS_READ_ONLY) (version 25.3.6.10636.altinitytest (altinity build)) (from [::1]:38894) (comment: 01103_optimize_drop_race_zookeeper.sh) (query 1, line 1) (in query: INSERT INTO concurrent_optimize_table SELECT rand(1), rand(2), 1 / rand(3), toString(rand(4)), [rand(5), rand(6)], rand(7) % 2 ? NULL : generateUUIDv4(), (rand(8), rand(9)) FROM numbers(10000)), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000a9b78ab 4. /build/src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:866: DB::ReplicatedMergeTreeSinkImpl::commitPart(std::shared_ptr const&, std::shared_ptr&, String const&, unsigned long)::'lambda1'()::operator()() const @ 0x000000001660eed7 5. /build/src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:1124: DB::ReplicatedMergeTreeSinkImpl::commitPart(std::shared_ptr const&, std::shared_ptr&, String const&, unsigned long)::'lambda2'()::operator()() const @ 0x000000001660d1f2 6. /build/src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:1157: void DB::ZooKeeperRetriesControl::retryLoop::commitPart(std::shared_ptr const&, std::shared_ptr&, String const&, unsigned long)::'lambda3'()&, void DB::ZooKeeperRetriesControl::retryLoop::commitPart(std::shared_ptr const&, std::shared_ptr&, String const&, unsigned long)::'lambda3'()>(DB::ReplicatedMergeTreeSinkImpl::commitPart(std::shared_ptr const&, std::shared_ptr&, String const&, unsigned long)::'lambda3'()&&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::commitPart(std::shared_ptr const&, std::shared_ptr&, String const&, unsigned long)::'lambda3'()&&, void DB::ZooKeeperRetriesControl::retryLoop::commitPart(std::shared_ptr const&, std::shared_ptr&, String const&, unsigned long)::'lambda3'()>(DB::ReplicatedMergeTreeSinkImpl::commitPart(std::shared_ptr const&, std::shared_ptr&, String const&, unsigned long)::'lambda3'()&&)::'lambda'()&&) @ 0x000000001660d07f 7. /build/src/Common/ZooKeeper/ZooKeeperRetries.h:52: DB::ReplicatedMergeTreeSinkImpl::commitPart(std::shared_ptr const&, std::shared_ptr&, String const&, unsigned long) @ 0x00000000165fd951 8. /build/src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:492: DB::ReplicatedMergeTreeSinkImpl::finishDelayedChunk(std::shared_ptr const&) @ 0x00000000165f277d 9. /build/src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:437: DB::ReplicatedMergeTreeSinkImpl::consume(DB::Chunk&) @ 0x00000000165fbd00 10. /build/src/Processors/Sinks/SinkToStorage.cpp:10: DB::SinkToStorage::onConsume(DB::Chunk) @ 0x0000000016cee093 11. /build/src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: void std::__function::__policy_invoker::__call_impl[abi:se190107]>(std::__function::__policy_storage const*) @ 0x0000000016c0ad89 12. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000016c0abf5 13. /build/src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: DB::ExceptionKeepingTransform::work() @ 0x0000000016c0a6fe 14. /build/src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x00000000169bd00f 15. /build/src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x00000000169b2105 16. /build/src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeSingleThread(unsigned long) @ 0x00000000169b23be 17. /build/src/Processors/Executors/PipelineExecutor.cpp:416: void std::__function::__policy_invoker::__call_impl[abi:se190107]>(std::__function::__policy_storage const*) @ 0x00000000169b2e3f 18. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc6653 19. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000000fccc4c3 20. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc3d92 21. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fcca080 22. ? @ 0x00007fbc6213eac3 23. ? @ 0x00007fbc621d0850 2025.07.28 11:58:40.686569 [ 4446 ] {} TCPHandler: Code: 60. DB::Exception: Table test_15.concurrent_optimize_table does not exist. (UNKNOWN_TABLE), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000a06a8eb 4. /build/src/Databases/IDatabase.cpp:41: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x0000000013dd565f 5. /build/src/Interpreters/DatabaseCatalog.cpp:442: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x00000000144f0869 6. /build/src/Interpreters/DatabaseCatalog.cpp:976: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x00000000144f6c88 7. /build/src/Interpreters/InterpreterInsertQuery.cpp:169: DB::InterpreterInsertQuery::getTable(DB::ASTInsertQuery&) @ 0x000000001492bf04 8. /build/src/Interpreters/InterpreterInsertQuery.cpp:829: DB::InterpreterInsertQuery::execute() @ 0x0000000014933938 9. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88dc9 10. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 11. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 12. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 13. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 14. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 16. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 17. ? @ 0x00007fbc6213eac3 18. ? @ 0x00007fbc621d0850 2025.07.28 11:58:40.713548 [ 17191 ] {} TCPHandler: Code: 242. DB::Exception: Table is in readonly mode due to shutdown: replica_path=/clickhouse/tables/01103_optimize_drop_race_zookeeper_test_15/concurrent_optimize_table/replicas/1. (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000a9b78ab 4. /build/src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:866: DB::ReplicatedMergeTreeSinkImpl::commitPart(std::shared_ptr const&, std::shared_ptr&, String const&, unsigned long)::'lambda1'()::operator()() const @ 0x000000001660eed7 5. /build/src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:1124: DB::ReplicatedMergeTreeSinkImpl::commitPart(std::shared_ptr const&, std::shared_ptr&, String const&, unsigned long)::'lambda2'()::operator()() const @ 0x000000001660d1f2 6. /build/src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:1157: void DB::ZooKeeperRetriesControl::retryLoop::commitPart(std::shared_ptr const&, std::shared_ptr&, String const&, unsigned long)::'lambda3'()&, void DB::ZooKeeperRetriesControl::retryLoop::commitPart(std::shared_ptr const&, std::shared_ptr&, String const&, unsigned long)::'lambda3'()>(DB::ReplicatedMergeTreeSinkImpl::commitPart(std::shared_ptr const&, std::shared_ptr&, String const&, unsigned long)::'lambda3'()&&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::commitPart(std::shared_ptr const&, std::shared_ptr&, String const&, unsigned long)::'lambda3'()&&, void DB::ZooKeeperRetriesControl::retryLoop::commitPart(std::shared_ptr const&, std::shared_ptr&, String const&, unsigned long)::'lambda3'()>(DB::ReplicatedMergeTreeSinkImpl::commitPart(std::shared_ptr const&, std::shared_ptr&, String const&, unsigned long)::'lambda3'()&&)::'lambda'()&&) @ 0x000000001660d07f 7. /build/src/Common/ZooKeeper/ZooKeeperRetries.h:52: DB::ReplicatedMergeTreeSinkImpl::commitPart(std::shared_ptr const&, std::shared_ptr&, String const&, unsigned long) @ 0x00000000165fd951 8. /build/src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:492: DB::ReplicatedMergeTreeSinkImpl::finishDelayedChunk(std::shared_ptr const&) @ 0x00000000165f277d 9. /build/src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:437: DB::ReplicatedMergeTreeSinkImpl::consume(DB::Chunk&) @ 0x00000000165fbd00 10. /build/src/Processors/Sinks/SinkToStorage.cpp:10: DB::SinkToStorage::onConsume(DB::Chunk) @ 0x0000000016cee093 11. /build/src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: void std::__function::__policy_invoker::__call_impl[abi:se190107]>(std::__function::__policy_storage const*) @ 0x0000000016c0ad89 12. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000016c0abf5 13. /build/src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: DB::ExceptionKeepingTransform::work() @ 0x0000000016c0a6fe 14. /build/src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x00000000169bd00f 15. /build/src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x00000000169b2105 16. /build/src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeSingleThread(unsigned long) @ 0x00000000169b23be 17. /build/src/Processors/Executors/PipelineExecutor.cpp:416: void std::__function::__policy_invoker::__call_impl[abi:se190107]>(std::__function::__policy_storage const*) @ 0x00000000169b2e3f 18. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc6653 19. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000000fccc4c3 20. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc3d92 21. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fcca080 22. ? @ 0x00007fbc6213eac3 23. ? @ 0x00007fbc621d0850 Job's origin stack trace: 0. /build/src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000000fc33b84 1. /build/src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000000fcc2ea7 2. /build/src/Common/ThreadPool.cpp:401: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fcc7f1c 3. /build/src/Common/ThreadPool.cpp:494: ThreadPoolImpl>::scheduleOrThrowOnError(std::function, Priority) @ 0x000000000fcc7a0e 4. /build/src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::spawnThreadsImpl() @ 0x00000000169b2c0c 5. /build/src/Processors/Executors/PipelineExecutor.cpp:394: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x00000000169b0ba7 6. /build/src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x00000000169b03f4 7. /build/src/Processors/Executors/CompletedPipelineExecutor.cpp:42: void std::__function::__policy_invoker::__call_impl[abi:se190107]::ThreadFromGlobalPoolImpl(DB::CompletedPipelineExecutor::execute()::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169af7e1 8. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc3d92 9. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fcca080 10. ? @ 0x00007fbc6213eac3 11. ? @ 0x00007fbc621d0850 Job's origin stack trace: 0. /build/src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000000fc33b84 1. /build/src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000000fcc2ea7 2. /build/src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fcc535c 3. /build/src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000000fcc584d 4. /build/src/Common/ThreadPool.h:279: DB::CompletedPipelineExecutor::execute() @ 0x00000000169af267 5. /build/src/Server/TCPHandler.cpp:707: DB::TCPHandler::runImpl() @ 0x00000000168e6b2e 6. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 7. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 8. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 9. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 10. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 11. ? @ 0x00007fbc6213eac3 12. ? @ 0x00007fbc621d0850 2025.07.28 11:58:40.725904 [ 7625 ] {4c2f0d46-b880-4149-b6d6-3048bb5cae61} executeQuery: Code: 60. DB::Exception: Table test_15.concurrent_optimize_table does not exist. (UNKNOWN_TABLE) (version 25.3.6.10636.altinitytest (altinity build)) (from [::1]:39004) (comment: 01103_optimize_drop_race_zookeeper.sh) (query 1, line 1) (in query: OPTIMIZE TABLE concurrent_optimize_table FINAL), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000a06a8eb 4. /build/src/Databases/IDatabase.cpp:41: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x0000000013dd565f 5. /build/src/Interpreters/DatabaseCatalog.cpp:442: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x00000000144f0869 6. /build/src/Interpreters/DatabaseCatalog.cpp:976: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x00000000144f6c88 7. /build/src/Interpreters/InterpreterOptimizeQuery.cpp:40: DB::InterpreterOptimizeQuery::execute() @ 0x0000000014cd71de 8. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88dc9 9. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 10. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 11. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 12. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 13. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 14. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 15. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 16. ? @ 0x00007fbc6213eac3 17. ? @ 0x00007fbc621d0850 2025.07.28 11:58:40.798804 [ 7625 ] {} TCPHandler: Code: 60. DB::Exception: Table test_15.concurrent_optimize_table does not exist. (UNKNOWN_TABLE), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000a06a8eb 4. /build/src/Databases/IDatabase.cpp:41: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x0000000013dd565f 5. /build/src/Interpreters/DatabaseCatalog.cpp:442: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x00000000144f0869 6. /build/src/Interpreters/DatabaseCatalog.cpp:976: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x00000000144f6c88 7. /build/src/Interpreters/InterpreterOptimizeQuery.cpp:40: DB::InterpreterOptimizeQuery::execute() @ 0x0000000014cd71de 8. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88dc9 9. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 10. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 11. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 12. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 13. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 14. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 15. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 16. ? @ 0x00007fbc6213eac3 17. ? @ 0x00007fbc621d0850 2025.07.28 11:58:40.886890 [ 3287 ] {9a6809cb-ac48-4ce4-9a28-07c9488c2a51} executeQuery: Code: 60. DB::Exception: Table test_15.concurrent_optimize_table does not exist. (UNKNOWN_TABLE) (version 25.3.6.10636.altinitytest (altinity build)) (from [::1]:39048) (comment: 01103_optimize_drop_race_zookeeper.sh) (query 1, line 1) (in query: OPTIMIZE TABLE concurrent_optimize_table FINAL), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000a06a8eb 4. /build/src/Databases/IDatabase.cpp:41: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x0000000013dd565f 5. /build/src/Interpreters/DatabaseCatalog.cpp:442: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x00000000144f0869 6. /build/src/Interpreters/DatabaseCatalog.cpp:976: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x00000000144f6c88 7. /build/src/Interpreters/InterpreterOptimizeQuery.cpp:40: DB::InterpreterOptimizeQuery::execute() @ 0x0000000014cd71de 8. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88dc9 9. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 10. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 11. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 12. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 13. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 14. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 15. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 16. ? @ 0x00007fbc6213eac3 17. ? @ 0x00007fbc621d0850 2025.07.28 11:58:40.911266 [ 3287 ] {} TCPHandler: Code: 60. DB::Exception: Table test_15.concurrent_optimize_table does not exist. (UNKNOWN_TABLE), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000a06a8eb 4. /build/src/Databases/IDatabase.cpp:41: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x0000000013dd565f 5. /build/src/Interpreters/DatabaseCatalog.cpp:442: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x00000000144f0869 6. /build/src/Interpreters/DatabaseCatalog.cpp:976: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x00000000144f6c88 7. /build/src/Interpreters/InterpreterOptimizeQuery.cpp:40: DB::InterpreterOptimizeQuery::execute() @ 0x0000000014cd71de 8. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88dc9 9. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 10. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 11. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 12. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 13. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 14. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 15. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 16. ? @ 0x00007fbc6213eac3 17. ? @ 0x00007fbc621d0850 2025.07.28 11:58:40.919827 [ 17306 ] {fd910bbc-b7a3-46ea-9399-ae9928abacd2} executeQuery: Code: 60. DB::Exception: Table test_15.concurrent_optimize_table does not exist. (UNKNOWN_TABLE) (version 25.3.6.10636.altinitytest (altinity build)) (from [::1]:39054) (comment: 01103_optimize_drop_race_zookeeper.sh) (query 1, line 1) (in query: INSERT INTO concurrent_optimize_table SELECT rand(1), rand(2), 1 / rand(3), toString(rand(4)), [rand(5), rand(6)], rand(7) % 2 ? NULL : generateUUIDv4(), (rand(8), rand(9)) FROM numbers(10000)), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000a06a8eb 4. /build/src/Databases/IDatabase.cpp:41: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x0000000013dd565f 5. /build/src/Interpreters/DatabaseCatalog.cpp:442: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x00000000144f0869 6. /build/src/Interpreters/DatabaseCatalog.cpp:976: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x00000000144f6c88 7. /build/src/Interpreters/InterpreterInsertQuery.cpp:169: DB::InterpreterInsertQuery::getTable(DB::ASTInsertQuery&) @ 0x000000001492bf04 8. /build/src/Interpreters/InterpreterInsertQuery.cpp:829: DB::InterpreterInsertQuery::execute() @ 0x0000000014933938 9. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88dc9 10. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 11. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 12. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 13. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 14. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 16. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 17. ? @ 0x00007fbc6213eac3 18. ? @ 0x00007fbc621d0850 2025.07.28 11:58:40.931355 [ 5879 ] {765b4825-8c7e-4a0e-bdcf-c644655399bc} executeQuery: Code: 60. DB::Exception: Table test_15.concurrent_optimize_table does not exist. (UNKNOWN_TABLE) (version 25.3.6.10636.altinitytest (altinity build)) (from [::1]:39070) (comment: 01103_optimize_drop_race_zookeeper.sh) (query 1, line 1) (in query: INSERT INTO concurrent_optimize_table SELECT rand(1), rand(2), 1 / rand(3), toString(rand(4)), [rand(5), rand(6)], rand(7) % 2 ? NULL : generateUUIDv4(), (rand(8), rand(9)) FROM numbers(10000)), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000a06a8eb 4. /build/src/Databases/IDatabase.cpp:41: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x0000000013dd565f 5. /build/src/Interpreters/DatabaseCatalog.cpp:442: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x00000000144f0869 6. /build/src/Interpreters/DatabaseCatalog.cpp:976: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x00000000144f6c88 7. /build/src/Interpreters/InterpreterInsertQuery.cpp:169: DB::InterpreterInsertQuery::getTable(DB::ASTInsertQuery&) @ 0x000000001492bf04 8. /build/src/Interpreters/InterpreterInsertQuery.cpp:829: DB::InterpreterInsertQuery::execute() @ 0x0000000014933938 9. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88dc9 10. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 11. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 12. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 13. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 14. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 16. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 17. ? @ 0x00007fbc6213eac3 18. ? @ 0x00007fbc621d0850 2025.07.28 11:58:40.954285 [ 17306 ] {} TCPHandler: Code: 60. DB::Exception: Table test_15.concurrent_optimize_table does not exist. (UNKNOWN_TABLE), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000a06a8eb 4. /build/src/Databases/IDatabase.cpp:41: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x0000000013dd565f 5. /build/src/Interpreters/DatabaseCatalog.cpp:442: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x00000000144f0869 6. /build/src/Interpreters/DatabaseCatalog.cpp:976: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x00000000144f6c88 7. /build/src/Interpreters/InterpreterInsertQuery.cpp:169: DB::InterpreterInsertQuery::getTable(DB::ASTInsertQuery&) @ 0x000000001492bf04 8. /build/src/Interpreters/InterpreterInsertQuery.cpp:829: DB::InterpreterInsertQuery::execute() @ 0x0000000014933938 9. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88dc9 10. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 11. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 12. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 13. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 14. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 16. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 17. ? @ 0x00007fbc6213eac3 18. ? @ 0x00007fbc621d0850 2025.07.28 11:58:40.968031 [ 5879 ] {} TCPHandler: Code: 60. DB::Exception: Table test_15.concurrent_optimize_table does not exist. (UNKNOWN_TABLE), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000a06a8eb 4. /build/src/Databases/IDatabase.cpp:41: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x0000000013dd565f 5. /build/src/Interpreters/DatabaseCatalog.cpp:442: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x00000000144f0869 6. /build/src/Interpreters/DatabaseCatalog.cpp:976: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x00000000144f6c88 7. /build/src/Interpreters/InterpreterInsertQuery.cpp:169: DB::InterpreterInsertQuery::getTable(DB::ASTInsertQuery&) @ 0x000000001492bf04 8. /build/src/Interpreters/InterpreterInsertQuery.cpp:829: DB::InterpreterInsertQuery::execute() @ 0x0000000014933938 9. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88dc9 10. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 11. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 12. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 13. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 14. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 16. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 17. ? @ 0x00007fbc6213eac3 18. ? @ 0x00007fbc621d0850 2025.07.28 11:58:40.980763 [ 4446 ] {d4ab4c96-9348-4316-a707-274376cd478f} executeQuery: Code: 60. DB::Exception: Table test_15.concurrent_optimize_table does not exist. (UNKNOWN_TABLE) (version 25.3.6.10636.altinitytest (altinity build)) (from [::1]:39034) (comment: 01103_optimize_drop_race_zookeeper.sh) (query 1, line 1) (in query: INSERT INTO concurrent_optimize_table SELECT rand(1), rand(2), 1 / rand(3), toString(rand(4)), [rand(5), rand(6)], rand(7) % 2 ? NULL : generateUUIDv4(), (rand(8), rand(9)) FROM numbers(10000)), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000a06a8eb 4. /build/src/Databases/IDatabase.cpp:41: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x0000000013dd565f 5. /build/src/Interpreters/DatabaseCatalog.cpp:442: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x00000000144f0869 6. /build/src/Interpreters/DatabaseCatalog.cpp:976: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x00000000144f6c88 7. /build/src/Interpreters/InterpreterInsertQuery.cpp:169: DB::InterpreterInsertQuery::getTable(DB::ASTInsertQuery&) @ 0x000000001492bf04 8. /build/src/Interpreters/InterpreterInsertQuery.cpp:829: DB::InterpreterInsertQuery::execute() @ 0x0000000014933938 9. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88dc9 10. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 11. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 12. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 13. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 14. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 16. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 17. ? @ 0x00007fbc6213eac3 18. ? @ 0x00007fbc621d0850 2025.07.28 11:58:41.000122 [ 7625 ] {de459490-031e-4e5e-a1c7-b76130d50a0f} executeQuery: Code: 60. DB::Exception: Table test_15.concurrent_optimize_table does not exist. (UNKNOWN_TABLE) (version 25.3.6.10636.altinitytest (altinity build)) (from [::1]:39082) (comment: 01103_optimize_drop_race_zookeeper.sh) (query 1, line 1) (in query: OPTIMIZE TABLE concurrent_optimize_table FINAL), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000a06a8eb 4. /build/src/Databases/IDatabase.cpp:41: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x0000000013dd565f 5. /build/src/Interpreters/DatabaseCatalog.cpp:442: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x00000000144f0869 6. /build/src/Interpreters/DatabaseCatalog.cpp:976: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x00000000144f6c88 7. /build/src/Interpreters/InterpreterOptimizeQuery.cpp:40: DB::InterpreterOptimizeQuery::execute() @ 0x0000000014cd71de 8. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88dc9 9. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 10. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 11. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 12. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 13. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 14. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 15. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 16. ? @ 0x00007fbc6213eac3 17. ? @ 0x00007fbc621d0850 2025.07.28 11:58:41.000527 [ 4446 ] {} TCPHandler: Code: 60. DB::Exception: Table test_15.concurrent_optimize_table does not exist. (UNKNOWN_TABLE), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000a06a8eb 4. /build/src/Databases/IDatabase.cpp:41: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x0000000013dd565f 5. /build/src/Interpreters/DatabaseCatalog.cpp:442: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x00000000144f0869 6. /build/src/Interpreters/DatabaseCatalog.cpp:976: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x00000000144f6c88 7. /build/src/Interpreters/InterpreterInsertQuery.cpp:169: DB::InterpreterInsertQuery::getTable(DB::ASTInsertQuery&) @ 0x000000001492bf04 8. /build/src/Interpreters/InterpreterInsertQuery.cpp:829: DB::InterpreterInsertQuery::execute() @ 0x0000000014933938 9. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88dc9 10. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 11. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 12. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 13. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 14. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 16. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 17. ? @ 0x00007fbc6213eac3 18. ? @ 0x00007fbc621d0850 2025.07.28 11:58:41.027676 [ 7625 ] {} TCPHandler: Code: 60. DB::Exception: Table test_15.concurrent_optimize_table does not exist. (UNKNOWN_TABLE), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000a06a8eb 4. /build/src/Databases/IDatabase.cpp:41: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x0000000013dd565f 5. /build/src/Interpreters/DatabaseCatalog.cpp:442: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x00000000144f0869 6. /build/src/Interpreters/DatabaseCatalog.cpp:976: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x00000000144f6c88 7. /build/src/Interpreters/InterpreterOptimizeQuery.cpp:40: DB::InterpreterOptimizeQuery::execute() @ 0x0000000014cd71de 8. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88dc9 9. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 10. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 11. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 12. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 13. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 14. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 15. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 16. ? @ 0x00007fbc6213eac3 17. ? @ 0x00007fbc621d0850 2025.07.28 11:58:41.094391 [ 17611 ] {1c1ac901-9be9-4895-bbf1-fb02a9f40d2a} executeQuery: Code: 60. DB::Exception: Table test_15.concurrent_optimize_table does not exist. (UNKNOWN_TABLE) (version 25.3.6.10636.altinitytest (altinity build)) (from [::1]:39094) (comment: 01103_optimize_drop_race_zookeeper.sh) (query 1, line 1) (in query: OPTIMIZE TABLE concurrent_optimize_table FINAL), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000a06a8eb 4. /build/src/Databases/IDatabase.cpp:41: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x0000000013dd565f 5. /build/src/Interpreters/DatabaseCatalog.cpp:442: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x00000000144f0869 6. /build/src/Interpreters/DatabaseCatalog.cpp:976: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x00000000144f6c88 7. /build/src/Interpreters/InterpreterOptimizeQuery.cpp:40: DB::InterpreterOptimizeQuery::execute() @ 0x0000000014cd71de 8. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88dc9 9. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 10. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 11. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 12. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 13. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 14. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 15. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 16. ? @ 0x00007fbc6213eac3 17. ? @ 0x00007fbc621d0850 2025.07.28 11:58:41.104022 [ 17208 ] {4d2c6c00-75c2-4e19-8eae-b6318d25c843} executeQuery: Code: 60. DB::Exception: Table test_15.concurrent_optimize_table does not exist. (UNKNOWN_TABLE) (version 25.3.6.10636.altinitytest (altinity build)) (from [::1]:39072) (comment: 01103_optimize_drop_race_zookeeper.sh) (query 1, line 1) (in query: INSERT INTO concurrent_optimize_table SELECT rand(1), rand(2), 1 / rand(3), toString(rand(4)), [rand(5), rand(6)], rand(7) % 2 ? NULL : generateUUIDv4(), (rand(8), rand(9)) FROM numbers(10000)), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000a06a8eb 4. /build/src/Databases/IDatabase.cpp:41: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x0000000013dd565f 5. /build/src/Interpreters/DatabaseCatalog.cpp:442: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x00000000144f0869 6. /build/src/Interpreters/DatabaseCatalog.cpp:976: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x00000000144f6c88 7. /build/src/Interpreters/InterpreterInsertQuery.cpp:169: DB::InterpreterInsertQuery::getTable(DB::ASTInsertQuery&) @ 0x000000001492bf04 8. /build/src/Interpreters/InterpreterInsertQuery.cpp:829: DB::InterpreterInsertQuery::execute() @ 0x0000000014933938 9. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88dc9 10. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 11. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 12. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 13. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 14. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 16. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 17. ? @ 0x00007fbc6213eac3 18. ? @ 0x00007fbc621d0850 2025.07.28 11:58:41.112615 [ 17611 ] {} TCPHandler: Code: 60. DB::Exception: Table test_15.concurrent_optimize_table does not exist. (UNKNOWN_TABLE), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000a06a8eb 4. /build/src/Databases/IDatabase.cpp:41: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x0000000013dd565f 5. /build/src/Interpreters/DatabaseCatalog.cpp:442: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x00000000144f0869 6. /build/src/Interpreters/DatabaseCatalog.cpp:976: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x00000000144f6c88 7. /build/src/Interpreters/InterpreterOptimizeQuery.cpp:40: DB::InterpreterOptimizeQuery::execute() @ 0x0000000014cd71de 8. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88dc9 9. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 10. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 11. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 12. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 13. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 14. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 15. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 16. ? @ 0x00007fbc6213eac3 17. ? @ 0x00007fbc621d0850 2025.07.28 11:58:41.130859 [ 17208 ] {} TCPHandler: Code: 60. DB::Exception: Table test_15.concurrent_optimize_table does not exist. (UNKNOWN_TABLE), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000a06a8eb 4. /build/src/Databases/IDatabase.cpp:41: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x0000000013dd565f 5. /build/src/Interpreters/DatabaseCatalog.cpp:442: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x00000000144f0869 6. /build/src/Interpreters/DatabaseCatalog.cpp:976: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x00000000144f6c88 7. /build/src/Interpreters/InterpreterInsertQuery.cpp:169: DB::InterpreterInsertQuery::getTable(DB::ASTInsertQuery&) @ 0x000000001492bf04 8. /build/src/Interpreters/InterpreterInsertQuery.cpp:829: DB::InterpreterInsertQuery::execute() @ 0x0000000014933938 9. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88dc9 10. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 11. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 12. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 13. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 14. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 16. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 17. ? @ 0x00007fbc6213eac3 18. ? @ 0x00007fbc621d0850 2025.07.28 11:58:41.171080 [ 5327 ] {3afd81f9-ab03-496a-9979-83019526d107} executeQuery: Code: 253. DB::Exception: Replica /clickhouse/tables/01103_optimize_drop_race_zookeeper_test_15/concurrent_optimize_table/replicas/1 already exists. (REPLICA_ALREADY_EXISTS) (version 25.3.6.10636.altinitytest (altinity build)) (from [::1]:38986) (comment: 01103_optimize_drop_race_zookeeper.sh) (query 2, line 2) (in query: CREATE TABLE concurrent_optimize_table (`a` UInt8, `b` Int16, `c` Float32, `d` String, `e` Array(UInt8), `f` Nullable(UUID), `g` Tuple(UInt8, UInt16)) ENGINE = ReplicatedMergeTree('/clickhouse/tables/01103_optimize_drop_race_zookeeper_test_15/concurrent_optimize_table', '1') PARTITION BY b % 10 ORDER BY a SETTINGS old_parts_lifetime = 1, cleanup_delay_period = 0, cleanup_delay_period_random_add = 0, cleanup_thread_preferred_points_per_iteration = 0, index_granularity = 31489, 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 = 20868213, compact_parts_max_bytes_to_buffer = 108362629, compact_parts_max_granules_to_buffer = 1, compact_parts_merge_max_bytes_to_prefetch_part = 18898448, merge_max_block_size = 13220, prefer_fetch_merged_part_size_threshold = 1, vertical_merge_algorithm_min_rows_to_activate = 1000000, vertical_merge_algorithm_min_columns_to_activate = 76, min_merge_bytes_to_use_direct_io = 10737418240, index_granularity_bytes = 7046892, use_const_adaptive_granularity = false, 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 = true, cache_populated_by_fetch = false, marks_compress_block_size = 84392, primary_key_compress_block_size = 23861, 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. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000a9b78ab 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:1237: DB::StorageReplicatedMergeTree::createReplicaAttempt(std::shared_ptr const&, std::shared_ptr) const @ 0x0000000015ea1634 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:1087: DB::StorageReplicatedMergeTree::createReplica(std::shared_ptr const&, DB::ZooKeeperRetriesInfo const&) const @ 0x0000000015e8c7b5 6. /build/src/Storages/StorageReplicatedMergeTree.cpp:624: DB::StorageReplicatedMergeTree::StorageReplicatedMergeTree(DB::TableZnodeInfo const&, DB::LoadingStrictnessLevel, DB::StorageID const&, String const&, DB::StorageInMemoryMetadata const&, std::shared_ptr, String const&, DB::MergeTreeData::MergingParams const&, std::unique_ptr>, bool, DB::ZooKeeperRetriesInfo const&) @ 0x0000000015e8979f 7. /build/contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: std::shared_ptr std::allocate_shared[abi:se190107], DB::TableZnodeInfo&, DB::LoadingStrictnessLevel const&, DB::StorageID const&, String const&, DB::StorageInMemoryMetadata&, std::shared_ptr&, String&, DB::MergeTreeData::MergingParams&, std::unique_ptr>, bool&, DB::ZooKeeperRetriesInfo&, 0>(std::allocator const&, DB::TableZnodeInfo&, DB::LoadingStrictnessLevel const&, DB::StorageID const&, String const&, DB::StorageInMemoryMetadata&, std::shared_ptr&, String&, DB::MergeTreeData::MergingParams&, std::unique_ptr>&&, bool&, DB::ZooKeeperRetriesInfo&) @ 0x000000001663250b 8. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:851: DB::create(DB::StorageFactory::Arguments const&) @ 0x000000001662ef92 9. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000015d81ea2 10. /build/src/Interpreters/InterpreterCreateQuery.cpp:1945: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x00000000149009bb 11. /build/src/Interpreters/InterpreterCreateQuery.cpp:1743: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000148f9aa9 12. /build/src/Interpreters/InterpreterCreateQuery.cpp:2352: DB::InterpreterCreateQuery::execute() @ 0x0000000014905a41 13. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88dc9 14. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 15. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 16. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 17. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 18. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 19. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 20. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 21. ? @ 0x00007fbc6213eac3 22. ? @ 0x00007fbc621d0850 2025.07.28 11:58:41.179031 [ 5327 ] {} TCPHandler: Code: 253. DB::Exception: Replica /clickhouse/tables/01103_optimize_drop_race_zookeeper_test_15/concurrent_optimize_table/replicas/1 already exists. (REPLICA_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000a9b78ab 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:1237: DB::StorageReplicatedMergeTree::createReplicaAttempt(std::shared_ptr const&, std::shared_ptr) const @ 0x0000000015ea1634 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:1087: DB::StorageReplicatedMergeTree::createReplica(std::shared_ptr const&, DB::ZooKeeperRetriesInfo const&) const @ 0x0000000015e8c7b5 6. /build/src/Storages/StorageReplicatedMergeTree.cpp:624: DB::StorageReplicatedMergeTree::StorageReplicatedMergeTree(DB::TableZnodeInfo const&, DB::LoadingStrictnessLevel, DB::StorageID const&, String const&, DB::StorageInMemoryMetadata const&, std::shared_ptr, String const&, DB::MergeTreeData::MergingParams const&, std::unique_ptr>, bool, DB::ZooKeeperRetriesInfo const&) @ 0x0000000015e8979f 7. /build/contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: std::shared_ptr std::allocate_shared[abi:se190107], DB::TableZnodeInfo&, DB::LoadingStrictnessLevel const&, DB::StorageID const&, String const&, DB::StorageInMemoryMetadata&, std::shared_ptr&, String&, DB::MergeTreeData::MergingParams&, std::unique_ptr>, bool&, DB::ZooKeeperRetriesInfo&, 0>(std::allocator const&, DB::TableZnodeInfo&, DB::LoadingStrictnessLevel const&, DB::StorageID const&, String const&, DB::StorageInMemoryMetadata&, std::shared_ptr&, String&, DB::MergeTreeData::MergingParams&, std::unique_ptr>&&, bool&, DB::ZooKeeperRetriesInfo&) @ 0x000000001663250b 8. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:851: DB::create(DB::StorageFactory::Arguments const&) @ 0x000000001662ef92 9. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000015d81ea2 10. /build/src/Interpreters/InterpreterCreateQuery.cpp:1945: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x00000000149009bb 11. /build/src/Interpreters/InterpreterCreateQuery.cpp:1743: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000148f9aa9 12. /build/src/Interpreters/InterpreterCreateQuery.cpp:2352: DB::InterpreterCreateQuery::execute() @ 0x0000000014905a41 13. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88dc9 14. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 15. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 16. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 17. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 18. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 19. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 20. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 21. ? @ 0x00007fbc6213eac3 22. ? @ 0x00007fbc621d0850 2025.07.28 11:58:41.278415 [ 3287 ] {ebfb6f74-be3c-4c87-b279-1ac7f30827b7} executeQuery: Code: 60. DB::Exception: Table test_15.concurrent_optimize_table does not exist. (UNKNOWN_TABLE) (version 25.3.6.10636.altinitytest (altinity build)) (from [::1]:39116) (comment: 01103_optimize_drop_race_zookeeper.sh) (query 1, line 1) (in query: OPTIMIZE TABLE concurrent_optimize_table FINAL), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000a06a8eb 4. /build/src/Databases/IDatabase.cpp:41: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x0000000013dd565f 5. /build/src/Interpreters/DatabaseCatalog.cpp:442: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x00000000144f0869 6. /build/src/Interpreters/DatabaseCatalog.cpp:976: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x00000000144f6c88 7. /build/src/Interpreters/InterpreterOptimizeQuery.cpp:40: DB::InterpreterOptimizeQuery::execute() @ 0x0000000014cd71de 8. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88dc9 9. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 10. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 11. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 12. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 13. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 14. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 15. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 16. ? @ 0x00007fbc6213eac3 17. ? @ 0x00007fbc621d0850 2025.07.28 11:58:41.291898 [ 3287 ] {} TCPHandler: Code: 60. DB::Exception: Table test_15.concurrent_optimize_table does not exist. (UNKNOWN_TABLE), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000a06a8eb 4. /build/src/Databases/IDatabase.cpp:41: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x0000000013dd565f 5. /build/src/Interpreters/DatabaseCatalog.cpp:442: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x00000000144f0869 6. /build/src/Interpreters/DatabaseCatalog.cpp:976: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x00000000144f6c88 7. /build/src/Interpreters/InterpreterOptimizeQuery.cpp:40: DB::InterpreterOptimizeQuery::execute() @ 0x0000000014cd71de 8. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88dc9 9. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 10. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 11. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 12. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 13. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 14. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 15. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 16. ? @ 0x00007fbc6213eac3 17. ? @ 0x00007fbc621d0850 2025.07.28 11:58:41.306553 [ 17306 ] {dcba5033-4eb5-4170-bd2e-6f61958fa479} executeQuery: Code: 60. DB::Exception: Table test_15.concurrent_optimize_table does not exist. (UNKNOWN_TABLE) (version 25.3.6.10636.altinitytest (altinity build)) (from [::1]:39128) (comment: 01103_optimize_drop_race_zookeeper.sh) (query 1, line 1) (in query: INSERT INTO concurrent_optimize_table SELECT rand(1), rand(2), 1 / rand(3), toString(rand(4)), [rand(5), rand(6)], rand(7) % 2 ? NULL : generateUUIDv4(), (rand(8), rand(9)) FROM numbers(10000)), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000a06a8eb 4. /build/src/Databases/IDatabase.cpp:41: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x0000000013dd565f 5. /build/src/Interpreters/DatabaseCatalog.cpp:442: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x00000000144f0869 6. /build/src/Interpreters/DatabaseCatalog.cpp:976: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x00000000144f6c88 7. /build/src/Interpreters/InterpreterInsertQuery.cpp:169: DB::InterpreterInsertQuery::getTable(DB::ASTInsertQuery&) @ 0x000000001492bf04 8. /build/src/Interpreters/InterpreterInsertQuery.cpp:829: DB::InterpreterInsertQuery::execute() @ 0x0000000014933938 9. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88dc9 10. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 11. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 12. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 13. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 14. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 16. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 17. ? @ 0x00007fbc6213eac3 18. ? @ 0x00007fbc621d0850 2025.07.28 11:58:41.320272 [ 17306 ] {} TCPHandler: Code: 60. DB::Exception: Table test_15.concurrent_optimize_table does not exist. (UNKNOWN_TABLE), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000a06a8eb 4. /build/src/Databases/IDatabase.cpp:41: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x0000000013dd565f 5. /build/src/Interpreters/DatabaseCatalog.cpp:442: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x00000000144f0869 6. /build/src/Interpreters/DatabaseCatalog.cpp:976: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x00000000144f6c88 7. /build/src/Interpreters/InterpreterInsertQuery.cpp:169: DB::InterpreterInsertQuery::getTable(DB::ASTInsertQuery&) @ 0x000000001492bf04 8. /build/src/Interpreters/InterpreterInsertQuery.cpp:829: DB::InterpreterInsertQuery::execute() @ 0x0000000014933938 9. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88dc9 10. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 11. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 12. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 13. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 14. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 16. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 17. ? @ 0x00007fbc6213eac3 18. ? @ 0x00007fbc621d0850 2025.07.28 11:58:41.322842 [ 5879 ] {992a192c-329a-44d2-8daf-44c8e0015f7a} executeQuery: Code: 60. DB::Exception: Table test_15.concurrent_optimize_table does not exist. (UNKNOWN_TABLE) (version 25.3.6.10636.altinitytest (altinity build)) (from [::1]:39142) (comment: 01103_optimize_drop_race_zookeeper.sh) (query 1, line 1) (in query: INSERT INTO concurrent_optimize_table SELECT rand(1), rand(2), 1 / rand(3), toString(rand(4)), [rand(5), rand(6)], rand(7) % 2 ? NULL : generateUUIDv4(), (rand(8), rand(9)) FROM numbers(10000)), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000a06a8eb 4. /build/src/Databases/IDatabase.cpp:41: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x0000000013dd565f 5. /build/src/Interpreters/DatabaseCatalog.cpp:442: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x00000000144f0869 6. /build/src/Interpreters/DatabaseCatalog.cpp:976: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x00000000144f6c88 7. /build/src/Interpreters/InterpreterInsertQuery.cpp:169: DB::InterpreterInsertQuery::getTable(DB::ASTInsertQuery&) @ 0x000000001492bf04 8. /build/src/Interpreters/InterpreterInsertQuery.cpp:829: DB::InterpreterInsertQuery::execute() @ 0x0000000014933938 9. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88dc9 10. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 11. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 12. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 13. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 14. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 16. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 17. ? @ 0x00007fbc6213eac3 18. ? @ 0x00007fbc621d0850 2025.07.28 11:58:41.336227 [ 5879 ] {} TCPHandler: Code: 60. DB::Exception: Table test_15.concurrent_optimize_table does not exist. (UNKNOWN_TABLE), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000a06a8eb 4. /build/src/Databases/IDatabase.cpp:41: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x0000000013dd565f 5. /build/src/Interpreters/DatabaseCatalog.cpp:442: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x00000000144f0869 6. /build/src/Interpreters/DatabaseCatalog.cpp:976: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x00000000144f6c88 7. /build/src/Interpreters/InterpreterInsertQuery.cpp:169: DB::InterpreterInsertQuery::getTable(DB::ASTInsertQuery&) @ 0x000000001492bf04 8. /build/src/Interpreters/InterpreterInsertQuery.cpp:829: DB::InterpreterInsertQuery::execute() @ 0x0000000014933938 9. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88dc9 10. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 11. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 12. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 13. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 14. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 16. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 17. ? @ 0x00007fbc6213eac3 18. ? @ 0x00007fbc621d0850 2025.07.28 11:58:41.348923 [ 7625 ] {774acbf6-576c-40ae-8975-ce5a65f85030} executeQuery: Code: 60. DB::Exception: Table test_15.concurrent_optimize_table does not exist. (UNKNOWN_TABLE) (version 25.3.6.10636.altinitytest (altinity build)) (from [::1]:50878) (comment: 01103_optimize_drop_race_zookeeper.sh) (query 1, line 1) (in query: INSERT INTO concurrent_optimize_table SELECT rand(1), rand(2), 1 / rand(3), toString(rand(4)), [rand(5), rand(6)], rand(7) % 2 ? NULL : generateUUIDv4(), (rand(8), rand(9)) FROM numbers(10000)), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000a06a8eb 4. /build/src/Databases/IDatabase.cpp:41: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x0000000013dd565f 5. /build/src/Interpreters/DatabaseCatalog.cpp:442: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x00000000144f0869 6. /build/src/Interpreters/DatabaseCatalog.cpp:976: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x00000000144f6c88 7. /build/src/Interpreters/InterpreterInsertQuery.cpp:169: DB::InterpreterInsertQuery::getTable(DB::ASTInsertQuery&) @ 0x000000001492bf04 8. /build/src/Interpreters/InterpreterInsertQuery.cpp:829: DB::InterpreterInsertQuery::execute() @ 0x0000000014933938 9. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88dc9 10. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 11. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 12. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 13. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 14. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 16. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 17. ? @ 0x00007fbc6213eac3 18. ? @ 0x00007fbc621d0850 2025.07.28 11:58:41.373309 [ 4615 ] {} ExternalDictionariesLoader: Could not load external dictionary 'cc8b1a52-da70-449c-9c23-8d623c5fcc44', next update is scheduled at 2025-07-28 11:59:38: Code: 396. DB::Exception: Limit for result exceeded, max bytes: 1.00 B, current bytes: 36.00 B. (TOO_MANY_ROWS_OR_BYTES), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, char const*&, ReadableSize&&, ReadableSize&&) @ 0x0000000013bd4eeb 4. /build/src/QueryPipeline/SizeLimits.cpp:43: DB::SizeLimits::check(unsigned long, unsigned long, char const*, int, int) const @ 0x0000000013bd48a1 5. /build/src/Processors/Transforms/LimitsCheckingTransform.cpp:45: DB::LimitsCheckingTransform::transform(DB::Chunk&) @ 0x0000000016c1d2fb 6. /build/src/Processors/ISimpleTransform.h:33: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000011a9a453 7. /build/src/Processors/ISimpleTransform.cpp:89: DB::ISimpleTransform::work() @ 0x000000001699fca0 8. /build/src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x00000000169bd00f 9. /build/src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x00000000169b2105 10. /build/src/Processors/Executors/PipelineExecutor.cpp:170: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x00000000169b16a7 11. /build/src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x00000000169c081c 12. /build/src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x00000000169c0978 13. /build/src/Dictionaries/FlatDictionary.cpp:502: DB::FlatDictionary::loadData() @ 0x0000000011b424cb 14. /build/src/Dictionaries/FlatDictionary.cpp:46: DB::FlatDictionary::FlatDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, DB::FlatDictionary::Configuration, std::shared_ptr) @ 0x0000000011b42111 15. /build/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:se190107]> (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) @ 0x0000000011b5d3e2 16. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000012d8a61d 17. /build/src/Interpreters/ExternalDictionariesLoader.cpp:47: DB::ExternalDictionariesLoader::createObject(String const&, Poco::Util::AbstractConfiguration const&, String const&, String const&) const @ 0x00000000148a6f44 18. /build/src/Interpreters/ExternalLoader.cpp:1522: DB::ExternalLoader::LoadingDispatcher::loadSingleObject(String const&, DB::ExternalLoader::ObjectConfig const&, std::shared_ptr) @ 0x00000000148b2ee8 19. /build/src/Interpreters/ExternalLoader.cpp:998: DB::ExternalLoader::LoadingDispatcher::doLoading(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr) @ 0x00000000148b197d 20. /build/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()() @ 0x00000000148b5991 21. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc3d92 22. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fcca080 23. ? @ 0x00007fbc6213eac3 24. ? @ 0x00007fbc621d0850 (version 25.3.6.10636.altinitytest (altinity build)) 2025.07.28 11:58:41.386033 [ 7625 ] {} TCPHandler: Code: 60. DB::Exception: Table test_15.concurrent_optimize_table does not exist. (UNKNOWN_TABLE), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000a06a8eb 4. /build/src/Databases/IDatabase.cpp:41: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x0000000013dd565f 5. /build/src/Interpreters/DatabaseCatalog.cpp:442: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x00000000144f0869 6. /build/src/Interpreters/DatabaseCatalog.cpp:976: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x00000000144f6c88 7. /build/src/Interpreters/InterpreterInsertQuery.cpp:169: DB::InterpreterInsertQuery::getTable(DB::ASTInsertQuery&) @ 0x000000001492bf04 8. /build/src/Interpreters/InterpreterInsertQuery.cpp:829: DB::InterpreterInsertQuery::execute() @ 0x0000000014933938 9. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88dc9 10. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 11. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 12. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 13. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 14. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 16. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 17. ? @ 0x00007fbc6213eac3 18. ? @ 0x00007fbc621d0850 2025.07.28 11:58:41.455291 [ 4446 ] {c8265413-32e7-4b1f-a7f6-d9bac8917fcc} executeQuery: Code: 60. DB::Exception: Table test_15.concurrent_optimize_table does not exist. (UNKNOWN_TABLE) (version 25.3.6.10636.altinitytest (altinity build)) (from [::1]:50904) (comment: 01103_optimize_drop_race_zookeeper.sh) (query 1, line 1) (in query: OPTIMIZE TABLE concurrent_optimize_table FINAL), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000a06a8eb 4. /build/src/Databases/IDatabase.cpp:41: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x0000000013dd565f 5. /build/src/Interpreters/DatabaseCatalog.cpp:442: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x00000000144f0869 6. /build/src/Interpreters/DatabaseCatalog.cpp:976: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x00000000144f6c88 7. /build/src/Interpreters/InterpreterOptimizeQuery.cpp:40: DB::InterpreterOptimizeQuery::execute() @ 0x0000000014cd71de 8. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88dc9 9. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 10. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 11. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 12. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 13. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 14. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 15. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 16. ? @ 0x00007fbc6213eac3 17. ? @ 0x00007fbc621d0850 2025.07.28 11:58:41.464417 [ 4446 ] {} TCPHandler: Code: 60. DB::Exception: Table test_15.concurrent_optimize_table does not exist. (UNKNOWN_TABLE), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000a06a8eb 4. /build/src/Databases/IDatabase.cpp:41: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x0000000013dd565f 5. /build/src/Interpreters/DatabaseCatalog.cpp:442: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x00000000144f0869 6. /build/src/Interpreters/DatabaseCatalog.cpp:976: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x00000000144f6c88 7. /build/src/Interpreters/InterpreterOptimizeQuery.cpp:40: DB::InterpreterOptimizeQuery::execute() @ 0x0000000014cd71de 8. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88dc9 9. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 10. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 11. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 12. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 13. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 14. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 15. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 16. ? @ 0x00007fbc6213eac3 17. ? @ 0x00007fbc621d0850 2025.07.28 11:58:41.472216 [ 5327 ] {7f11fb4b-8219-432a-a8cf-6675d36bef9d} executeQuery: Code: 60. DB::Exception: Table test_15.concurrent_optimize_table does not exist. (UNKNOWN_TABLE) (version 25.3.6.10636.altinitytest (altinity build)) (from [::1]:50890) (comment: 01103_optimize_drop_race_zookeeper.sh) (query 1, line 1) (in query: INSERT INTO concurrent_optimize_table SELECT rand(1), rand(2), 1 / rand(3), toString(rand(4)), [rand(5), rand(6)], rand(7) % 2 ? NULL : generateUUIDv4(), (rand(8), rand(9)) FROM numbers(10000)), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000a06a8eb 4. /build/src/Databases/IDatabase.cpp:41: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x0000000013dd565f 5. /build/src/Interpreters/DatabaseCatalog.cpp:442: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x00000000144f0869 6. /build/src/Interpreters/DatabaseCatalog.cpp:976: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x00000000144f6c88 7. /build/src/Interpreters/InterpreterInsertQuery.cpp:169: DB::InterpreterInsertQuery::getTable(DB::ASTInsertQuery&) @ 0x000000001492bf04 8. /build/src/Interpreters/InterpreterInsertQuery.cpp:829: DB::InterpreterInsertQuery::execute() @ 0x0000000014933938 9. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88dc9 10. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 11. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 12. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 13. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 14. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 16. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 17. ? @ 0x00007fbc6213eac3 18. ? @ 0x00007fbc621d0850 2025.07.28 11:58:41.491375 [ 5327 ] {} TCPHandler: Code: 60. DB::Exception: Table test_15.concurrent_optimize_table does not exist. (UNKNOWN_TABLE), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000a06a8eb 4. /build/src/Databases/IDatabase.cpp:41: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x0000000013dd565f 5. /build/src/Interpreters/DatabaseCatalog.cpp:442: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x00000000144f0869 6. /build/src/Interpreters/DatabaseCatalog.cpp:976: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x00000000144f6c88 7. /build/src/Interpreters/InterpreterInsertQuery.cpp:169: DB::InterpreterInsertQuery::getTable(DB::ASTInsertQuery&) @ 0x000000001492bf04 8. /build/src/Interpreters/InterpreterInsertQuery.cpp:829: DB::InterpreterInsertQuery::execute() @ 0x0000000014933938 9. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88dc9 10. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 11. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 12. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 13. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 14. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 16. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 17. ? @ 0x00007fbc6213eac3 18. ? @ 0x00007fbc621d0850 2025.07.28 11:58:41.537751 [ 3287 ] {5d51e660-e50d-4480-b897-ebd7c1fd71cc} executeQuery: Code: 60. DB::Exception: Table test_15.concurrent_optimize_table does not exist. (UNKNOWN_TABLE) (version 25.3.6.10636.altinitytest (altinity build)) (from [::1]:50908) (comment: 01103_optimize_drop_race_zookeeper.sh) (query 1, line 1) (in query: OPTIMIZE TABLE concurrent_optimize_table FINAL), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000a06a8eb 4. /build/src/Databases/IDatabase.cpp:41: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x0000000013dd565f 5. /build/src/Interpreters/DatabaseCatalog.cpp:442: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x00000000144f0869 6. /build/src/Interpreters/DatabaseCatalog.cpp:976: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x00000000144f6c88 7. /build/src/Interpreters/InterpreterOptimizeQuery.cpp:40: DB::InterpreterOptimizeQuery::execute() @ 0x0000000014cd71de 8. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88dc9 9. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 10. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 11. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 12. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 13. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 14. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 15. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 16. ? @ 0x00007fbc6213eac3 17. ? @ 0x00007fbc621d0850 2025.07.28 11:58:41.555909 [ 3287 ] {} TCPHandler: Code: 60. DB::Exception: Table test_15.concurrent_optimize_table does not exist. (UNKNOWN_TABLE), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000a06a8eb 4. /build/src/Databases/IDatabase.cpp:41: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x0000000013dd565f 5. /build/src/Interpreters/DatabaseCatalog.cpp:442: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x00000000144f0869 6. /build/src/Interpreters/DatabaseCatalog.cpp:976: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x00000000144f6c88 7. /build/src/Interpreters/InterpreterOptimizeQuery.cpp:40: DB::InterpreterOptimizeQuery::execute() @ 0x0000000014cd71de 8. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88dc9 9. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 10. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 11. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 12. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 13. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 14. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 15. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 16. ? @ 0x00007fbc6213eac3 17. ? @ 0x00007fbc621d0850 2025.07.28 11:58:41.611799 [ 17611 ] {02e0ffd6-6cd6-4965-8abb-da86179cced6} executeQuery: Code: 60. DB::Exception: Table test_15.concurrent_optimize_table does not exist. (UNKNOWN_TABLE) (version 25.3.6.10636.altinitytest (altinity build)) (from [::1]:50934) (comment: 01103_optimize_drop_race_zookeeper.sh) (query 1, line 1) (in query: OPTIMIZE TABLE concurrent_optimize_table FINAL), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000a06a8eb 4. /build/src/Databases/IDatabase.cpp:41: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x0000000013dd565f 5. /build/src/Interpreters/DatabaseCatalog.cpp:442: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x00000000144f0869 6. /build/src/Interpreters/DatabaseCatalog.cpp:976: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x00000000144f6c88 7. /build/src/Interpreters/InterpreterOptimizeQuery.cpp:40: DB::InterpreterOptimizeQuery::execute() @ 0x0000000014cd71de 8. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88dc9 9. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 10. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 11. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 12. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 13. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 14. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 15. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 16. ? @ 0x00007fbc6213eac3 17. ? @ 0x00007fbc621d0850 2025.07.28 11:58:41.614559 [ 17611 ] {} TCPHandler: Code: 60. DB::Exception: Table test_15.concurrent_optimize_table does not exist. (UNKNOWN_TABLE), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000a06a8eb 4. /build/src/Databases/IDatabase.cpp:41: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x0000000013dd565f 5. /build/src/Interpreters/DatabaseCatalog.cpp:442: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x00000000144f0869 6. /build/src/Interpreters/DatabaseCatalog.cpp:976: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x00000000144f6c88 7. /build/src/Interpreters/InterpreterOptimizeQuery.cpp:40: DB::InterpreterOptimizeQuery::execute() @ 0x0000000014cd71de 8. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88dc9 9. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 10. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 11. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 12. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 13. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 14. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 15. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 16. ? @ 0x00007fbc6213eac3 17. ? @ 0x00007fbc621d0850 2025.07.28 11:58:41.640359 [ 5879 ] {b3cfac0f-18e1-4386-9876-915b09513995} executeQuery: Code: 60. DB::Exception: Table test_15.concurrent_optimize_table does not exist. (UNKNOWN_TABLE) (version 25.3.6.10636.altinitytest (altinity build)) (from [::1]:50924) (comment: 01103_optimize_drop_race_zookeeper.sh) (query 1, line 1) (in query: INSERT INTO concurrent_optimize_table SELECT rand(1), rand(2), 1 / rand(3), toString(rand(4)), [rand(5), rand(6)], rand(7) % 2 ? NULL : generateUUIDv4(), (rand(8), rand(9)) FROM numbers(10000)), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000a06a8eb 4. /build/src/Databases/IDatabase.cpp:41: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x0000000013dd565f 5. /build/src/Interpreters/DatabaseCatalog.cpp:442: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x00000000144f0869 6. /build/src/Interpreters/DatabaseCatalog.cpp:976: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x00000000144f6c88 7. /build/src/Interpreters/InterpreterInsertQuery.cpp:169: DB::InterpreterInsertQuery::getTable(DB::ASTInsertQuery&) @ 0x000000001492bf04 8. /build/src/Interpreters/InterpreterInsertQuery.cpp:829: DB::InterpreterInsertQuery::execute() @ 0x0000000014933938 9. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88dc9 10. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 11. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 12. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 13. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 14. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 16. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 17. ? @ 0x00007fbc6213eac3 18. ? @ 0x00007fbc621d0850 2025.07.28 11:58:41.662669 [ 5879 ] {} TCPHandler: Code: 60. DB::Exception: Table test_15.concurrent_optimize_table does not exist. (UNKNOWN_TABLE), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000a06a8eb 4. /build/src/Databases/IDatabase.cpp:41: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x0000000013dd565f 5. /build/src/Interpreters/DatabaseCatalog.cpp:442: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x00000000144f0869 6. /build/src/Interpreters/DatabaseCatalog.cpp:976: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x00000000144f6c88 7. /build/src/Interpreters/InterpreterInsertQuery.cpp:169: DB::InterpreterInsertQuery::getTable(DB::ASTInsertQuery&) @ 0x000000001492bf04 8. /build/src/Interpreters/InterpreterInsertQuery.cpp:829: DB::InterpreterInsertQuery::execute() @ 0x0000000014933938 9. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88dc9 10. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 11. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 12. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 13. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 14. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 16. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 17. ? @ 0x00007fbc6213eac3 18. ? @ 0x00007fbc621d0850 2025.07.28 11:58:41.687887 [ 17256 ] {b40e415c-1547-4605-a386-96739e223246} test_15.concurrent_optimize_table (7cfe5735-8263-4fcf-9734-2870fd1a3f46): Removing leftovers from table /clickhouse/tables/01103_optimize_drop_race_zookeeper_test_15/concurrent_optimize_table (this might take several minutes) 2025.07.28 11:58:41.742628 [ 4446 ] {be08941c-9859-44b4-a060-be943390e55d} executeQuery: Code: 60. DB::Exception: Table test_15.concurrent_optimize_table does not exist. (UNKNOWN_TABLE) (version 25.3.6.10636.altinitytest (altinity build)) (from [::1]:50936) (comment: 01103_optimize_drop_race_zookeeper.sh) (query 1, line 1) (in query: INSERT INTO concurrent_optimize_table SELECT rand(1), rand(2), 1 / rand(3), toString(rand(4)), [rand(5), rand(6)], rand(7) % 2 ? NULL : generateUUIDv4(), (rand(8), rand(9)) FROM numbers(10000)), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000a06a8eb 4. /build/src/Databases/IDatabase.cpp:41: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x0000000013dd565f 5. /build/src/Interpreters/DatabaseCatalog.cpp:442: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x00000000144f0869 6. /build/src/Interpreters/DatabaseCatalog.cpp:976: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x00000000144f6c88 7. /build/src/Interpreters/InterpreterInsertQuery.cpp:169: DB::InterpreterInsertQuery::getTable(DB::ASTInsertQuery&) @ 0x000000001492bf04 8. /build/src/Interpreters/InterpreterInsertQuery.cpp:829: DB::InterpreterInsertQuery::execute() @ 0x0000000014933938 9. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88dc9 10. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 11. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 12. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 13. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 14. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 16. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 17. ? @ 0x00007fbc6213eac3 18. ? @ 0x00007fbc621d0850 2025.07.28 11:58:41.743089 [ 7625 ] {7342bd30-ba2b-4010-851d-10a5638f8047} executeQuery: Code: 60. DB::Exception: Table test_15.concurrent_optimize_table does not exist. (UNKNOWN_TABLE) (version 25.3.6.10636.altinitytest (altinity build)) (from [::1]:50922) (comment: 01103_optimize_drop_race_zookeeper.sh) (query 1, line 1) (in query: INSERT INTO concurrent_optimize_table SELECT rand(1), rand(2), 1 / rand(3), toString(rand(4)), [rand(5), rand(6)], rand(7) % 2 ? NULL : generateUUIDv4(), (rand(8), rand(9)) FROM numbers(10000)), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000a06a8eb 4. /build/src/Databases/IDatabase.cpp:41: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x0000000013dd565f 5. /build/src/Interpreters/DatabaseCatalog.cpp:442: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x00000000144f0869 6. /build/src/Interpreters/DatabaseCatalog.cpp:976: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x00000000144f6c88 7. /build/src/Interpreters/InterpreterInsertQuery.cpp:169: DB::InterpreterInsertQuery::getTable(DB::ASTInsertQuery&) @ 0x000000001492bf04 8. /build/src/Interpreters/InterpreterInsertQuery.cpp:829: DB::InterpreterInsertQuery::execute() @ 0x0000000014933938 9. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88dc9 10. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 11. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 12. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 13. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 14. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 16. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 17. ? @ 0x00007fbc6213eac3 18. ? @ 0x00007fbc621d0850 2025.07.28 11:58:41.749525 [ 17256 ] {b40e415c-1547-4605-a386-96739e223246} test_15.concurrent_optimize_table (7cfe5735-8263-4fcf-9734-2870fd1a3f46): The leftovers from table /clickhouse/tables/01103_optimize_drop_race_zookeeper_test_15/concurrent_optimize_table were removed by another replica 2025.07.28 11:58:41.760346 [ 7625 ] {} TCPHandler: Code: 60. DB::Exception: Table test_15.concurrent_optimize_table does not exist. (UNKNOWN_TABLE), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000a06a8eb 4. /build/src/Databases/IDatabase.cpp:41: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x0000000013dd565f 5. /build/src/Interpreters/DatabaseCatalog.cpp:442: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x00000000144f0869 6. /build/src/Interpreters/DatabaseCatalog.cpp:976: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x00000000144f6c88 7. /build/src/Interpreters/InterpreterInsertQuery.cpp:169: DB::InterpreterInsertQuery::getTable(DB::ASTInsertQuery&) @ 0x000000001492bf04 8. /build/src/Interpreters/InterpreterInsertQuery.cpp:829: DB::InterpreterInsertQuery::execute() @ 0x0000000014933938 9. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88dc9 10. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 11. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 12. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 13. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 14. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 16. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 17. ? @ 0x00007fbc6213eac3 18. ? @ 0x00007fbc621d0850 2025.07.28 11:58:41.773041 [ 4446 ] {} TCPHandler: Code: 60. DB::Exception: Table test_15.concurrent_optimize_table does not exist. (UNKNOWN_TABLE), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000a06a8eb 4. /build/src/Databases/IDatabase.cpp:41: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x0000000013dd565f 5. /build/src/Interpreters/DatabaseCatalog.cpp:442: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x00000000144f0869 6. /build/src/Interpreters/DatabaseCatalog.cpp:976: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x00000000144f6c88 7. /build/src/Interpreters/InterpreterInsertQuery.cpp:169: DB::InterpreterInsertQuery::getTable(DB::ASTInsertQuery&) @ 0x000000001492bf04 8. /build/src/Interpreters/InterpreterInsertQuery.cpp:829: DB::InterpreterInsertQuery::execute() @ 0x0000000014933938 9. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88dc9 10. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 11. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 12. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 13. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 14. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 16. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 17. ? @ 0x00007fbc6213eac3 18. ? @ 0x00007fbc621d0850 2025.07.28 11:58:41.776312 [ 3969 ] {} test_13.rmt2 (7f9b740d-015c-470e-8cc6-8ba33be0dc63): auto DB::StorageReplicatedMergeTree::processQueueEntry(ReplicatedMergeTreeQueue::SelectedEntryPtr)::(anonymous class)::operator()(LogEntryPtr &) const: Code: 86. DB::HTTPException: Received error from remote server http://146b4357c08d:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Ftest%2F01165%2Ftest_13%2Frmt%2Freplicas%2F1&part=20250728_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.6.10636.altinitytest (altinity build)) '. (RECEIVED_ERROR_FROM_REMOTE_IO_SERVER), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.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 const&, int&&, String const&, unsigned long&&, String const&) @ 0x000000000feda8d9 4. /build/src/IO/HTTPCommon.cpp:104: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x000000000feda6e2 5. /build/src/IO/HTTPCommon.cpp:93: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x000000000feda537 6. /build/src/IO/ReadWriteBufferFromHTTP.cpp:277: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x000000001184a4c4 7. /build/src/IO/ReadWriteBufferFromHTTP.cpp:285: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x000000001184a615 8. /build/src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x000000001184ae59 9. /build/src/IO/ReadWriteBufferFromHTTP.cpp:472: void std::__function::__policy_invoker::__call_impl[abi:se190107]>(std::__function::__policy_storage const*) @ 0x000000001184cedd 10. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001184858b 11. /build/src/IO/ReadWriteBufferFromHTTP.cpp:465: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x000000001184bf0b 12. /build/src/IO/ReadBuffer.h:60: DB::ReadBuffer::next() @ 0x000000000a148c7b 13. /build/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) @ 0x0000000011849fb2 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]>&)>&, 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&) @ 0x0000000011841980 15. /build/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) @ 0x000000001621208e 16. /build/src/Storages/StorageReplicatedMergeTree.cpp:5228: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl[abi:se190107] const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000015f9a5fe 17. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000015ed8bfd 18. /build/src/Storages/StorageReplicatedMergeTree.cpp:2514: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x0000000015ec9aab 19. /build/src/Storages/StorageReplicatedMergeTree.cpp:2349: DB::StorageReplicatedMergeTree::executeLogEntry(DB::ReplicatedMergeTreeLogEntry&) @ 0x0000000015eba91b 20. /build/src/Storages/StorageReplicatedMergeTree.cpp:3876: bool std::__function::__policy_invoker&)>::__call_impl[abi:se190107])::$_1, bool (std::shared_ptr&)>>(std::__function::__policy_storage const*, std::shared_ptr&) @ 0x0000000015f9837e 21. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000165d6fc3 22. /build/src/Storages/StorageReplicatedMergeTree.cpp:3872: DB::StorageReplicatedMergeTree::processQueueEntry(std::shared_ptr) @ 0x0000000015efc18a 23. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001624c1b2 24. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000162f9c70 25. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x00000000162fa55a 26. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc6653 27. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000000fccc4c3 28. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc3d92 29. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fcca080 30. ? @ 0x00007fbc6213eac3 31. ? @ 0x00007fbc621d0850 (version 25.3.6.10636.altinitytest (altinity build)) 2025.07.28 11:58:41.833656 [ 5327 ] {b4005141-9eb9-482c-9053-6e6b65d100bb} executeQuery: Code: 60. DB::Exception: Table test_15.concurrent_optimize_table does not exist. (UNKNOWN_TABLE) (version 25.3.6.10636.altinitytest (altinity build)) (from [::1]:50944) (comment: 01103_optimize_drop_race_zookeeper.sh) (query 1, line 1) (in query: INSERT INTO concurrent_optimize_table SELECT rand(1), rand(2), 1 / rand(3), toString(rand(4)), [rand(5), rand(6)], rand(7) % 2 ? NULL : generateUUIDv4(), (rand(8), rand(9)) FROM numbers(10000)), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000a06a8eb 4. /build/src/Databases/IDatabase.cpp:41: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x0000000013dd565f 5. /build/src/Interpreters/DatabaseCatalog.cpp:442: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x00000000144f0869 6. /build/src/Interpreters/DatabaseCatalog.cpp:976: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x00000000144f6c88 7. /build/src/Interpreters/InterpreterInsertQuery.cpp:169: DB::InterpreterInsertQuery::getTable(DB::ASTInsertQuery&) @ 0x000000001492bf04 8. /build/src/Interpreters/InterpreterInsertQuery.cpp:829: DB::InterpreterInsertQuery::execute() @ 0x0000000014933938 9. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88dc9 10. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 11. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 12. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 13. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 14. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 16. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 17. ? @ 0x00007fbc6213eac3 18. ? @ 0x00007fbc621d0850 2025.07.28 11:58:41.860078 [ 3287 ] {48c72853-88d1-4698-9ff8-39d5dc930bf2} executeQuery: Code: 60. DB::Exception: Table test_15.concurrent_optimize_table does not exist. (UNKNOWN_TABLE) (version 25.3.6.10636.altinitytest (altinity build)) (from [::1]:50950) (comment: 01103_optimize_drop_race_zookeeper.sh) (query 1, line 1) (in query: OPTIMIZE TABLE concurrent_optimize_table FINAL), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000a06a8eb 4. /build/src/Databases/IDatabase.cpp:41: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x0000000013dd565f 5. /build/src/Interpreters/DatabaseCatalog.cpp:442: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x00000000144f0869 6. /build/src/Interpreters/DatabaseCatalog.cpp:976: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x00000000144f6c88 7. /build/src/Interpreters/InterpreterOptimizeQuery.cpp:40: DB::InterpreterOptimizeQuery::execute() @ 0x0000000014cd71de 8. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88dc9 9. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 10. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 11. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 12. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 13. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 14. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 15. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 16. ? @ 0x00007fbc6213eac3 17. ? @ 0x00007fbc621d0850 2025.07.28 11:58:41.870320 [ 7415 ] {} DDLWorker(test_9_db): Replica seems to be lost: our_log_ptr=152, max_log_ptr=152, local_digest=14274937624739372885, zk_digest=16463670767734240303 2025.07.28 11:58:41.870933 [ 7415 ] {} DatabaseReplicated (test_9_db): Will recover replica with staled log pointer 152 from log pointer 152 2025.07.28 11:58:41.884279 [ 3287 ] {} TCPHandler: Code: 60. DB::Exception: Table test_15.concurrent_optimize_table does not exist. (UNKNOWN_TABLE), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000a06a8eb 4. /build/src/Databases/IDatabase.cpp:41: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x0000000013dd565f 5. /build/src/Interpreters/DatabaseCatalog.cpp:442: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x00000000144f0869 6. /build/src/Interpreters/DatabaseCatalog.cpp:976: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x00000000144f6c88 7. /build/src/Interpreters/InterpreterOptimizeQuery.cpp:40: DB::InterpreterOptimizeQuery::execute() @ 0x0000000014cd71de 8. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88dc9 9. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 10. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 11. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 12. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 13. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 14. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 15. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 16. ? @ 0x00007fbc6213eac3 17. ? @ 0x00007fbc621d0850 2025.07.28 11:58:41.898095 [ 5327 ] {} TCPHandler: Code: 60. DB::Exception: Table test_15.concurrent_optimize_table does not exist. (UNKNOWN_TABLE), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000a06a8eb 4. /build/src/Databases/IDatabase.cpp:41: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x0000000013dd565f 5. /build/src/Interpreters/DatabaseCatalog.cpp:442: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x00000000144f0869 6. /build/src/Interpreters/DatabaseCatalog.cpp:976: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x00000000144f6c88 7. /build/src/Interpreters/InterpreterInsertQuery.cpp:169: DB::InterpreterInsertQuery::getTable(DB::ASTInsertQuery&) @ 0x000000001492bf04 8. /build/src/Interpreters/InterpreterInsertQuery.cpp:829: DB::InterpreterInsertQuery::execute() @ 0x0000000014933938 9. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88dc9 10. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 11. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 12. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 13. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 14. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 16. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 17. ? @ 0x00007fbc6213eac3 18. ? @ 0x00007fbc621d0850 2025.07.28 11:58:41.909120 [ 17256 ] {b40e415c-1547-4605-a386-96739e223246} test_15.concurrent_optimize_table (7cfe5735-8263-4fcf-9734-2870fd1a3f46): Removing leftovers from table /clickhouse/tables/01103_optimize_drop_race_zookeeper_test_15/concurrent_optimize_table (this might take several minutes) 2025.07.28 11:58:41.946884 [ 17256 ] {b40e415c-1547-4605-a386-96739e223246} test_15.concurrent_optimize_table (7cfe5735-8263-4fcf-9734-2870fd1a3f46): The leftovers from table /clickhouse/tables/01103_optimize_drop_race_zookeeper_test_15/concurrent_optimize_table were removed by another replica 2025.07.28 11:58:42.010305 [ 17270 ] {822fbf50-63c4-4fd4-8935-9ab2fe3fc02c} executeQuery: Code: 60. DB::Exception: Table test_15.concurrent_optimize_table does not exist. (UNKNOWN_TABLE) (version 25.3.6.10636.altinitytest (altinity build)) (from [::1]:51002) (comment: 01103_optimize_drop_race_zookeeper.sh) (query 1, line 1) (in query: INSERT INTO concurrent_optimize_table SELECT rand(1), rand(2), 1 / rand(3), toString(rand(4)), [rand(5), rand(6)], rand(7) % 2 ? NULL : generateUUIDv4(), (rand(8), rand(9)) FROM numbers(10000)), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000a06a8eb 4. /build/src/Databases/IDatabase.cpp:41: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x0000000013dd565f 5. /build/src/Interpreters/DatabaseCatalog.cpp:442: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x00000000144f0869 6. /build/src/Interpreters/DatabaseCatalog.cpp:976: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x00000000144f6c88 7. /build/src/Interpreters/InterpreterInsertQuery.cpp:169: DB::InterpreterInsertQuery::getTable(DB::ASTInsertQuery&) @ 0x000000001492bf04 8. /build/src/Interpreters/InterpreterInsertQuery.cpp:829: DB::InterpreterInsertQuery::execute() @ 0x0000000014933938 9. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88dc9 10. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 11. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 12. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 13. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 14. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 16. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 17. ? @ 0x00007fbc6213eac3 18. ? @ 0x00007fbc621d0850 2025.07.28 11:58:42.023172 [ 17270 ] {} TCPHandler: Code: 60. DB::Exception: Table test_15.concurrent_optimize_table does not exist. (UNKNOWN_TABLE), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000a06a8eb 4. /build/src/Databases/IDatabase.cpp:41: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x0000000013dd565f 5. /build/src/Interpreters/DatabaseCatalog.cpp:442: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x00000000144f0869 6. /build/src/Interpreters/DatabaseCatalog.cpp:976: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x00000000144f6c88 7. /build/src/Interpreters/InterpreterInsertQuery.cpp:169: DB::InterpreterInsertQuery::getTable(DB::ASTInsertQuery&) @ 0x000000001492bf04 8. /build/src/Interpreters/InterpreterInsertQuery.cpp:829: DB::InterpreterInsertQuery::execute() @ 0x0000000014933938 9. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88dc9 10. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 11. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 12. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 13. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 14. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 16. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 17. ? @ 0x00007fbc6213eac3 18. ? @ 0x00007fbc621d0850 2025.07.28 11:58:42.027605 [ 17611 ] {0b08f4b2-5a3a-4ac7-ac2c-51781fdb10c1} executeQuery: Code: 60. DB::Exception: Table test_15.concurrent_optimize_table does not exist. (UNKNOWN_TABLE) (version 25.3.6.10636.altinitytest (altinity build)) (from [::1]:50976) (comment: 01103_optimize_drop_race_zookeeper.sh) (query 1, line 1) (in query: OPTIMIZE TABLE concurrent_optimize_table FINAL), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000a06a8eb 4. /build/src/Databases/IDatabase.cpp:41: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x0000000013dd565f 5. /build/src/Interpreters/DatabaseCatalog.cpp:442: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x00000000144f0869 6. /build/src/Interpreters/DatabaseCatalog.cpp:976: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x00000000144f6c88 7. /build/src/Interpreters/InterpreterOptimizeQuery.cpp:40: DB::InterpreterOptimizeQuery::execute() @ 0x0000000014cd71de 8. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88dc9 9. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 10. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 11. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 12. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 13. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 14. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 15. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 16. ? @ 0x00007fbc6213eac3 17. ? @ 0x00007fbc621d0850 2025.07.28 11:58:42.069882 [ 3283 ] {a82e191a-f61e-4473-a1e7-745f47fc7127} executeQuery: Code: 60. DB::Exception: Table test_15.concurrent_optimize_table does not exist. (UNKNOWN_TABLE) (version 25.3.6.10636.altinitytest (altinity build)) (from [::1]:50964) (comment: 01103_optimize_drop_race_zookeeper.sh) (query 1, line 1) (in query: INSERT INTO concurrent_optimize_table SELECT rand(1), rand(2), 1 / rand(3), toString(rand(4)), [rand(5), rand(6)], rand(7) % 2 ? NULL : generateUUIDv4(), (rand(8), rand(9)) FROM numbers(10000)), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000a06a8eb 4. /build/src/Databases/IDatabase.cpp:41: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x0000000013dd565f 5. /build/src/Interpreters/DatabaseCatalog.cpp:442: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x00000000144f0869 6. /build/src/Interpreters/DatabaseCatalog.cpp:976: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x00000000144f6c88 7. /build/src/Interpreters/InterpreterInsertQuery.cpp:169: DB::InterpreterInsertQuery::getTable(DB::ASTInsertQuery&) @ 0x000000001492bf04 8. /build/src/Interpreters/InterpreterInsertQuery.cpp:829: DB::InterpreterInsertQuery::execute() @ 0x0000000014933938 9. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88dc9 10. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 11. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 12. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 13. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 14. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 16. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 17. ? @ 0x00007fbc6213eac3 18. ? @ 0x00007fbc621d0850 2025.07.28 11:58:42.075764 [ 5879 ] {cefd07fc-8ccf-4286-b458-1c4493203caa} executeQuery: Code: 60. DB::Exception: Table test_15.concurrent_optimize_table does not exist. (UNKNOWN_TABLE) (version 25.3.6.10636.altinitytest (altinity build)) (from [::1]:50968) (comment: 01103_optimize_drop_race_zookeeper.sh) (query 1, line 1) (in query: OPTIMIZE TABLE concurrent_optimize_table FINAL), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000a06a8eb 4. /build/src/Databases/IDatabase.cpp:41: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x0000000013dd565f 5. /build/src/Interpreters/DatabaseCatalog.cpp:442: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x00000000144f0869 6. /build/src/Interpreters/DatabaseCatalog.cpp:976: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x00000000144f6c88 7. /build/src/Interpreters/InterpreterOptimizeQuery.cpp:40: DB::InterpreterOptimizeQuery::execute() @ 0x0000000014cd71de 8. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88dc9 9. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 10. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 11. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 12. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 13. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 14. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 15. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 16. ? @ 0x00007fbc6213eac3 17. ? @ 0x00007fbc621d0850 2025.07.28 11:58:42.076435 [ 17611 ] {} TCPHandler: Code: 60. DB::Exception: Table test_15.concurrent_optimize_table does not exist. (UNKNOWN_TABLE), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000a06a8eb 4. /build/src/Databases/IDatabase.cpp:41: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x0000000013dd565f 5. /build/src/Interpreters/DatabaseCatalog.cpp:442: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x00000000144f0869 6. /build/src/Interpreters/DatabaseCatalog.cpp:976: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x00000000144f6c88 7. /build/src/Interpreters/InterpreterOptimizeQuery.cpp:40: DB::InterpreterOptimizeQuery::execute() @ 0x0000000014cd71de 8. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88dc9 9. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 10. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 11. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 12. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 13. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 14. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 15. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 16. ? @ 0x00007fbc6213eac3 17. ? @ 0x00007fbc621d0850 2025.07.28 11:58:42.076598 [ 17232 ] {80a0c17c-e24b-4679-a87e-dff0d82a0be0} executeQuery: Code: 60. DB::Exception: Table test_15.concurrent_optimize_table does not exist. (UNKNOWN_TABLE) (version 25.3.6.10636.altinitytest (altinity build)) (from [::1]:51016) (comment: 01103_optimize_drop_race_zookeeper.sh) (query 1, line 1) (in query: OPTIMIZE TABLE concurrent_optimize_table FINAL), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000a06a8eb 4. /build/src/Databases/IDatabase.cpp:41: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x0000000013dd565f 5. /build/src/Interpreters/DatabaseCatalog.cpp:442: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x00000000144f0869 6. /build/src/Interpreters/DatabaseCatalog.cpp:976: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x00000000144f6c88 7. /build/src/Interpreters/InterpreterOptimizeQuery.cpp:40: DB::InterpreterOptimizeQuery::execute() @ 0x0000000014cd71de 8. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88dc9 9. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 10. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 11. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 12. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 13. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 14. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 15. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 16. ? @ 0x00007fbc6213eac3 17. ? @ 0x00007fbc621d0850 2025.07.28 11:58:42.087788 [ 3283 ] {} TCPHandler: Code: 60. DB::Exception: Table test_15.concurrent_optimize_table does not exist. (UNKNOWN_TABLE), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000a06a8eb 4. /build/src/Databases/IDatabase.cpp:41: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x0000000013dd565f 5. /build/src/Interpreters/DatabaseCatalog.cpp:442: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x00000000144f0869 6. /build/src/Interpreters/DatabaseCatalog.cpp:976: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x00000000144f6c88 7. /build/src/Interpreters/InterpreterInsertQuery.cpp:169: DB::InterpreterInsertQuery::getTable(DB::ASTInsertQuery&) @ 0x000000001492bf04 8. /build/src/Interpreters/InterpreterInsertQuery.cpp:829: DB::InterpreterInsertQuery::execute() @ 0x0000000014933938 9. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88dc9 10. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 11. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 12. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 13. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 14. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 16. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 17. ? @ 0x00007fbc6213eac3 18. ? @ 0x00007fbc621d0850 2025.07.28 11:58:42.095756 [ 17243 ] {f117b829-d18f-4808-942b-b71f912456c5} executeQuery: Code: 60. DB::Exception: Table test_15.concurrent_optimize_table does not exist. (UNKNOWN_TABLE) (version 25.3.6.10636.altinitytest (altinity build)) (from [::1]:50992) (comment: 01103_optimize_drop_race_zookeeper.sh) (query 1, line 1) (in query: INSERT INTO concurrent_optimize_table SELECT rand(1), rand(2), 1 / rand(3), toString(rand(4)), [rand(5), rand(6)], rand(7) % 2 ? NULL : generateUUIDv4(), (rand(8), rand(9)) FROM numbers(10000)), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000a06a8eb 4. /build/src/Databases/IDatabase.cpp:41: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x0000000013dd565f 5. /build/src/Interpreters/DatabaseCatalog.cpp:442: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x00000000144f0869 6. /build/src/Interpreters/DatabaseCatalog.cpp:976: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x00000000144f6c88 7. /build/src/Interpreters/InterpreterInsertQuery.cpp:169: DB::InterpreterInsertQuery::getTable(DB::ASTInsertQuery&) @ 0x000000001492bf04 8. /build/src/Interpreters/InterpreterInsertQuery.cpp:829: DB::InterpreterInsertQuery::execute() @ 0x0000000014933938 9. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88dc9 10. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 11. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 12. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 13. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 14. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 16. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 17. ? @ 0x00007fbc6213eac3 18. ? @ 0x00007fbc621d0850 2025.07.28 11:58:42.103067 [ 5879 ] {} TCPHandler: Code: 60. DB::Exception: Table test_15.concurrent_optimize_table does not exist. (UNKNOWN_TABLE), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000a06a8eb 4. /build/src/Databases/IDatabase.cpp:41: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x0000000013dd565f 5. /build/src/Interpreters/DatabaseCatalog.cpp:442: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x00000000144f0869 6. /build/src/Interpreters/DatabaseCatalog.cpp:976: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x00000000144f6c88 7. /build/src/Interpreters/InterpreterOptimizeQuery.cpp:40: DB::InterpreterOptimizeQuery::execute() @ 0x0000000014cd71de 8. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88dc9 9. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 10. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 11. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 12. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 13. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 14. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 15. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 16. ? @ 0x00007fbc6213eac3 17. ? @ 0x00007fbc621d0850 2025.07.28 11:58:42.103616 [ 17232 ] {} TCPHandler: Code: 60. DB::Exception: Table test_15.concurrent_optimize_table does not exist. (UNKNOWN_TABLE), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000a06a8eb 4. /build/src/Databases/IDatabase.cpp:41: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x0000000013dd565f 5. /build/src/Interpreters/DatabaseCatalog.cpp:442: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x00000000144f0869 6. /build/src/Interpreters/DatabaseCatalog.cpp:976: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x00000000144f6c88 7. /build/src/Interpreters/InterpreterOptimizeQuery.cpp:40: DB::InterpreterOptimizeQuery::execute() @ 0x0000000014cd71de 8. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88dc9 9. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 10. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 11. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 12. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 13. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 14. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 15. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 16. ? @ 0x00007fbc6213eac3 17. ? @ 0x00007fbc621d0850 2025.07.28 11:58:42.136428 [ 17243 ] {} TCPHandler: Code: 60. DB::Exception: Table test_15.concurrent_optimize_table does not exist. (UNKNOWN_TABLE), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000a06a8eb 4. /build/src/Databases/IDatabase.cpp:41: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x0000000013dd565f 5. /build/src/Interpreters/DatabaseCatalog.cpp:442: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x00000000144f0869 6. /build/src/Interpreters/DatabaseCatalog.cpp:976: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x00000000144f6c88 7. /build/src/Interpreters/InterpreterInsertQuery.cpp:169: DB::InterpreterInsertQuery::getTable(DB::ASTInsertQuery&) @ 0x000000001492bf04 8. /build/src/Interpreters/InterpreterInsertQuery.cpp:829: DB::InterpreterInsertQuery::execute() @ 0x0000000014933938 9. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88dc9 10. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 11. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 12. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 13. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 14. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 16. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 17. ? @ 0x00007fbc6213eac3 18. ? @ 0x00007fbc621d0850 2025.07.28 11:58:42.148531 [ 17256 ] {b40e415c-1547-4605-a386-96739e223246} test_15.concurrent_optimize_table (7cfe5735-8263-4fcf-9734-2870fd1a3f46): Removing leftovers from table /clickhouse/tables/01103_optimize_drop_race_zookeeper_test_15/concurrent_optimize_table (this might take several minutes) 2025.07.28 11:58:42.167900 [ 17256 ] {b40e415c-1547-4605-a386-96739e223246} test_15.concurrent_optimize_table (7cfe5735-8263-4fcf-9734-2870fd1a3f46): The leftovers from table /clickhouse/tables/01103_optimize_drop_race_zookeeper_test_15/concurrent_optimize_table were removed by another replica 2025.07.28 11:58:42.175966 [ 5112 ] {2c0cefb9-9319-4c63-b5d9-f2a9c9c9ee3b} executeQuery: Code: 60. DB::Exception: Table test_15.concurrent_optimize_table does not exist. (UNKNOWN_TABLE) (version 25.3.6.10636.altinitytest (altinity build)) (from [::1]:51018) (comment: 01103_optimize_drop_race_zookeeper.sh) (query 1, line 1) (in query: INSERT INTO concurrent_optimize_table SELECT rand(1), rand(2), 1 / rand(3), toString(rand(4)), [rand(5), rand(6)], rand(7) % 2 ? NULL : generateUUIDv4(), (rand(8), rand(9)) FROM numbers(10000)), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000a06a8eb 4. /build/src/Databases/IDatabase.cpp:41: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x0000000013dd565f 5. /build/src/Interpreters/DatabaseCatalog.cpp:442: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x00000000144f0869 6. /build/src/Interpreters/DatabaseCatalog.cpp:976: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x00000000144f6c88 7. /build/src/Interpreters/InterpreterInsertQuery.cpp:169: DB::InterpreterInsertQuery::getTable(DB::ASTInsertQuery&) @ 0x000000001492bf04 8. /build/src/Interpreters/InterpreterInsertQuery.cpp:829: DB::InterpreterInsertQuery::execute() @ 0x0000000014933938 9. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88dc9 10. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 11. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 12. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 13. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 14. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 16. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 17. ? @ 0x00007fbc6213eac3 18. ? @ 0x00007fbc621d0850 2025.07.28 11:58:42.199803 [ 5112 ] {} TCPHandler: Code: 60. DB::Exception: Table test_15.concurrent_optimize_table does not exist. (UNKNOWN_TABLE), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000a06a8eb 4. /build/src/Databases/IDatabase.cpp:41: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x0000000013dd565f 5. /build/src/Interpreters/DatabaseCatalog.cpp:442: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x00000000144f0869 6. /build/src/Interpreters/DatabaseCatalog.cpp:976: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x00000000144f6c88 7. /build/src/Interpreters/InterpreterInsertQuery.cpp:169: DB::InterpreterInsertQuery::getTable(DB::ASTInsertQuery&) @ 0x000000001492bf04 8. /build/src/Interpreters/InterpreterInsertQuery.cpp:829: DB::InterpreterInsertQuery::execute() @ 0x0000000014933938 9. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88dc9 10. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 11. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 12. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 13. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 14. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 16. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 17. ? @ 0x00007fbc6213eac3 18. ? @ 0x00007fbc621d0850 2025.07.28 11:58:42.320484 [ 5879 ] {26aebfea-40da-4de9-ad65-7daeb33d6a00} executeQuery: Code: 60. DB::Exception: Table test_15.concurrent_optimize_table does not exist. (UNKNOWN_TABLE) (version 25.3.6.10636.altinitytest (altinity build)) (from [::1]:51038) (comment: 01103_optimize_drop_race_zookeeper.sh) (query 1, line 1) (in query: INSERT INTO concurrent_optimize_table SELECT rand(1), rand(2), 1 / rand(3), toString(rand(4)), [rand(5), rand(6)], rand(7) % 2 ? NULL : generateUUIDv4(), (rand(8), rand(9)) FROM numbers(10000)), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000a06a8eb 4. /build/src/Databases/IDatabase.cpp:41: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x0000000013dd565f 5. /build/src/Interpreters/DatabaseCatalog.cpp:442: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x00000000144f0869 6. /build/src/Interpreters/DatabaseCatalog.cpp:976: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x00000000144f6c88 7. /build/src/Interpreters/InterpreterInsertQuery.cpp:169: DB::InterpreterInsertQuery::getTable(DB::ASTInsertQuery&) @ 0x000000001492bf04 8. /build/src/Interpreters/InterpreterInsertQuery.cpp:829: DB::InterpreterInsertQuery::execute() @ 0x0000000014933938 9. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88dc9 10. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 11. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 12. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 13. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 14. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 16. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 17. ? @ 0x00007fbc6213eac3 18. ? @ 0x00007fbc621d0850 2025.07.28 11:58:42.336124 [ 17256 ] {b40e415c-1547-4605-a386-96739e223246} test_15.concurrent_optimize_table (7cfe5735-8263-4fcf-9734-2870fd1a3f46): Removing leftovers from table /clickhouse/tables/01103_optimize_drop_race_zookeeper_test_15/concurrent_optimize_table (this might take several minutes) 2025.07.28 11:58:42.343639 [ 5879 ] {} TCPHandler: Code: 60. DB::Exception: Table test_15.concurrent_optimize_table does not exist. (UNKNOWN_TABLE), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000a06a8eb 4. /build/src/Databases/IDatabase.cpp:41: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x0000000013dd565f 5. /build/src/Interpreters/DatabaseCatalog.cpp:442: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x00000000144f0869 6. /build/src/Interpreters/DatabaseCatalog.cpp:976: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x00000000144f6c88 7. /build/src/Interpreters/InterpreterInsertQuery.cpp:169: DB::InterpreterInsertQuery::getTable(DB::ASTInsertQuery&) @ 0x000000001492bf04 8. /build/src/Interpreters/InterpreterInsertQuery.cpp:829: DB::InterpreterInsertQuery::execute() @ 0x0000000014933938 9. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88dc9 10. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 11. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 12. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 13. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 14. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 16. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 17. ? @ 0x00007fbc6213eac3 18. ? @ 0x00007fbc621d0850 2025.07.28 11:58:42.348651 [ 17243 ] {768ee609-2041-4ce5-9f18-fb5ac6fdd531} executeQuery: Code: 60. DB::Exception: Table test_15.concurrent_optimize_table does not exist. (UNKNOWN_TABLE) (version 25.3.6.10636.altinitytest (altinity build)) (from [::1]:51060) (comment: 01103_optimize_drop_race_zookeeper.sh) (query 1, line 1) (in query: INSERT INTO concurrent_optimize_table SELECT rand(1), rand(2), 1 / rand(3), toString(rand(4)), [rand(5), rand(6)], rand(7) % 2 ? NULL : generateUUIDv4(), (rand(8), rand(9)) FROM numbers(10000)), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000a06a8eb 4. /build/src/Databases/IDatabase.cpp:41: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x0000000013dd565f 5. /build/src/Interpreters/DatabaseCatalog.cpp:442: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x00000000144f0869 6. /build/src/Interpreters/DatabaseCatalog.cpp:976: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x00000000144f6c88 7. /build/src/Interpreters/InterpreterInsertQuery.cpp:169: DB::InterpreterInsertQuery::getTable(DB::ASTInsertQuery&) @ 0x000000001492bf04 8. /build/src/Interpreters/InterpreterInsertQuery.cpp:829: DB::InterpreterInsertQuery::execute() @ 0x0000000014933938 9. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88dc9 10. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 11. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 12. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 13. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 14. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 16. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 17. ? @ 0x00007fbc6213eac3 18. ? @ 0x00007fbc621d0850 2025.07.28 11:58:42.352853 [ 17256 ] {b40e415c-1547-4605-a386-96739e223246} test_15.concurrent_optimize_table (7cfe5735-8263-4fcf-9734-2870fd1a3f46): The leftovers from table /clickhouse/tables/01103_optimize_drop_race_zookeeper_test_15/concurrent_optimize_table were removed by another replica 2025.07.28 11:58:42.396499 [ 17270 ] {dc1593fb-21f7-4cab-8805-38b714924865} executeQuery: Code: 60. DB::Exception: Table test_15.concurrent_optimize_table does not exist. (UNKNOWN_TABLE) (version 25.3.6.10636.altinitytest (altinity build)) (from [::1]:51066) (comment: 01103_optimize_drop_race_zookeeper.sh) (query 1, line 1) (in query: OPTIMIZE TABLE concurrent_optimize_table FINAL), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000a06a8eb 4. /build/src/Databases/IDatabase.cpp:41: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x0000000013dd565f 5. /build/src/Interpreters/DatabaseCatalog.cpp:442: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x00000000144f0869 6. /build/src/Interpreters/DatabaseCatalog.cpp:976: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x00000000144f6c88 7. /build/src/Interpreters/InterpreterOptimizeQuery.cpp:40: DB::InterpreterOptimizeQuery::execute() @ 0x0000000014cd71de 8. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88dc9 9. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 10. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 11. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 12. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 13. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 14. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 15. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 16. ? @ 0x00007fbc6213eac3 17. ? @ 0x00007fbc621d0850 2025.07.28 11:58:42.419769 [ 17243 ] {} TCPHandler: Code: 60. DB::Exception: Table test_15.concurrent_optimize_table does not exist. (UNKNOWN_TABLE), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000a06a8eb 4. /build/src/Databases/IDatabase.cpp:41: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x0000000013dd565f 5. /build/src/Interpreters/DatabaseCatalog.cpp:442: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x00000000144f0869 6. /build/src/Interpreters/DatabaseCatalog.cpp:976: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x00000000144f6c88 7. /build/src/Interpreters/InterpreterInsertQuery.cpp:169: DB::InterpreterInsertQuery::getTable(DB::ASTInsertQuery&) @ 0x000000001492bf04 8. /build/src/Interpreters/InterpreterInsertQuery.cpp:829: DB::InterpreterInsertQuery::execute() @ 0x0000000014933938 9. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88dc9 10. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 11. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 12. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 13. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 14. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 16. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 17. ? @ 0x00007fbc6213eac3 18. ? @ 0x00007fbc621d0850 2025.07.28 11:58:42.431062 [ 17270 ] {} TCPHandler: Code: 60. DB::Exception: Table test_15.concurrent_optimize_table does not exist. (UNKNOWN_TABLE), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000a06a8eb 4. /build/src/Databases/IDatabase.cpp:41: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x0000000013dd565f 5. /build/src/Interpreters/DatabaseCatalog.cpp:442: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x00000000144f0869 6. /build/src/Interpreters/DatabaseCatalog.cpp:976: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x00000000144f6c88 7. /build/src/Interpreters/InterpreterOptimizeQuery.cpp:40: DB::InterpreterOptimizeQuery::execute() @ 0x0000000014cd71de 8. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88dc9 9. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 10. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 11. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 12. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 13. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 14. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 15. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 16. ? @ 0x00007fbc6213eac3 17. ? @ 0x00007fbc621d0850 2025.07.28 11:58:42.432069 [ 17611 ] {f0aab01e-b476-4212-b306-92e282067b9e} executeQuery: Code: 60. DB::Exception: Table test_15.concurrent_optimize_table does not exist. (UNKNOWN_TABLE) (version 25.3.6.10636.altinitytest (altinity build)) (from [::1]:51048) (comment: 01103_optimize_drop_race_zookeeper.sh) (query 1, line 1) (in query: INSERT INTO concurrent_optimize_table SELECT rand(1), rand(2), 1 / rand(3), toString(rand(4)), [rand(5), rand(6)], rand(7) % 2 ? NULL : generateUUIDv4(), (rand(8), rand(9)) FROM numbers(10000)), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000a06a8eb 4. /build/src/Databases/IDatabase.cpp:41: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x0000000013dd565f 5. /build/src/Interpreters/DatabaseCatalog.cpp:442: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x00000000144f0869 6. /build/src/Interpreters/DatabaseCatalog.cpp:976: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x00000000144f6c88 7. /build/src/Interpreters/InterpreterInsertQuery.cpp:169: DB::InterpreterInsertQuery::getTable(DB::ASTInsertQuery&) @ 0x000000001492bf04 8. /build/src/Interpreters/InterpreterInsertQuery.cpp:829: DB::InterpreterInsertQuery::execute() @ 0x0000000014933938 9. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88dc9 10. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 11. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 12. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 13. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 14. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 16. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 17. ? @ 0x00007fbc6213eac3 18. ? @ 0x00007fbc621d0850 2025.07.28 11:58:42.459036 [ 17611 ] {} TCPHandler: Code: 60. DB::Exception: Table test_15.concurrent_optimize_table does not exist. (UNKNOWN_TABLE), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000a06a8eb 4. /build/src/Databases/IDatabase.cpp:41: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x0000000013dd565f 5. /build/src/Interpreters/DatabaseCatalog.cpp:442: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x00000000144f0869 6. /build/src/Interpreters/DatabaseCatalog.cpp:976: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x00000000144f6c88 7. /build/src/Interpreters/InterpreterInsertQuery.cpp:169: DB::InterpreterInsertQuery::getTable(DB::ASTInsertQuery&) @ 0x000000001492bf04 8. /build/src/Interpreters/InterpreterInsertQuery.cpp:829: DB::InterpreterInsertQuery::execute() @ 0x0000000014933938 9. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88dc9 10. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 11. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 12. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 13. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 14. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 16. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 17. ? @ 0x00007fbc6213eac3 18. ? @ 0x00007fbc621d0850 2025.07.28 11:58:42.488760 [ 17232 ] {6b5fc252-bee4-435a-9de0-c42d5743dc9f} executeQuery: Code: 60. DB::Exception: Table test_15.concurrent_optimize_table does not exist. (UNKNOWN_TABLE) (version 25.3.6.10636.altinitytest (altinity build)) (from [::1]:51080) (comment: 01103_optimize_drop_race_zookeeper.sh) (query 1, line 1) (in query: INSERT INTO concurrent_optimize_table SELECT rand(1), rand(2), 1 / rand(3), toString(rand(4)), [rand(5), rand(6)], rand(7) % 2 ? NULL : generateUUIDv4(), (rand(8), rand(9)) FROM numbers(10000)), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000a06a8eb 4. /build/src/Databases/IDatabase.cpp:41: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x0000000013dd565f 5. /build/src/Interpreters/DatabaseCatalog.cpp:442: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x00000000144f0869 6. /build/src/Interpreters/DatabaseCatalog.cpp:976: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x00000000144f6c88 7. /build/src/Interpreters/InterpreterInsertQuery.cpp:169: DB::InterpreterInsertQuery::getTable(DB::ASTInsertQuery&) @ 0x000000001492bf04 8. /build/src/Interpreters/InterpreterInsertQuery.cpp:829: DB::InterpreterInsertQuery::execute() @ 0x0000000014933938 9. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88dc9 10. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 11. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 12. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 13. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 14. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 16. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 17. ? @ 0x00007fbc6213eac3 18. ? @ 0x00007fbc621d0850 2025.07.28 11:58:42.511438 [ 17232 ] {} TCPHandler: Code: 60. DB::Exception: Table test_15.concurrent_optimize_table does not exist. (UNKNOWN_TABLE), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000a06a8eb 4. /build/src/Databases/IDatabase.cpp:41: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x0000000013dd565f 5. /build/src/Interpreters/DatabaseCatalog.cpp:442: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x00000000144f0869 6. /build/src/Interpreters/DatabaseCatalog.cpp:976: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x00000000144f6c88 7. /build/src/Interpreters/InterpreterInsertQuery.cpp:169: DB::InterpreterInsertQuery::getTable(DB::ASTInsertQuery&) @ 0x000000001492bf04 8. /build/src/Interpreters/InterpreterInsertQuery.cpp:829: DB::InterpreterInsertQuery::execute() @ 0x0000000014933938 9. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88dc9 10. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 11. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 12. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 13. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 14. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 16. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 17. ? @ 0x00007fbc6213eac3 18. ? @ 0x00007fbc621d0850 2025.07.28 11:58:42.533477 [ 3960 ] {} test_13.rmt2 (7f9b740d-015c-470e-8cc6-8ba33be0dc63): auto DB::StorageReplicatedMergeTree::processQueueEntry(ReplicatedMergeTreeQueue::SelectedEntryPtr)::(anonymous class)::operator()(LogEntryPtr &) const: Code: 86. DB::HTTPException: Received error from remote server http://146b4357c08d:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Ftest%2F01165%2Ftest_13%2Frmt%2Freplicas%2F1&part=20250728_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.6.10636.altinitytest (altinity build)) '. (RECEIVED_ERROR_FROM_REMOTE_IO_SERVER), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.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 const&, int&&, String const&, unsigned long&&, String const&) @ 0x000000000feda8d9 4. /build/src/IO/HTTPCommon.cpp:104: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x000000000feda6e2 5. /build/src/IO/HTTPCommon.cpp:93: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x000000000feda537 6. /build/src/IO/ReadWriteBufferFromHTTP.cpp:277: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x000000001184a4c4 7. /build/src/IO/ReadWriteBufferFromHTTP.cpp:285: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x000000001184a615 8. /build/src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x000000001184ae59 9. /build/src/IO/ReadWriteBufferFromHTTP.cpp:472: void std::__function::__policy_invoker::__call_impl[abi:se190107]>(std::__function::__policy_storage const*) @ 0x000000001184cedd 10. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001184858b 11. /build/src/IO/ReadWriteBufferFromHTTP.cpp:465: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x000000001184bf0b 12. /build/src/IO/ReadBuffer.h:60: DB::ReadBuffer::next() @ 0x000000000a148c7b 13. /build/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) @ 0x0000000011849fb2 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]>&)>&, 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&) @ 0x0000000011841980 15. /build/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) @ 0x000000001621208e 16. /build/src/Storages/StorageReplicatedMergeTree.cpp:5228: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl[abi:se190107] const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000015f9a5fe 17. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000015ed8bfd 18. /build/src/Storages/StorageReplicatedMergeTree.cpp:2514: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x0000000015ec9aab 19. /build/src/Storages/StorageReplicatedMergeTree.cpp:2349: DB::StorageReplicatedMergeTree::executeLogEntry(DB::ReplicatedMergeTreeLogEntry&) @ 0x0000000015eba91b 20. /build/src/Storages/StorageReplicatedMergeTree.cpp:3876: bool std::__function::__policy_invoker&)>::__call_impl[abi:se190107])::$_1, bool (std::shared_ptr&)>>(std::__function::__policy_storage const*, std::shared_ptr&) @ 0x0000000015f9837e 21. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000165d6fc3 22. /build/src/Storages/StorageReplicatedMergeTree.cpp:3872: DB::StorageReplicatedMergeTree::processQueueEntry(std::shared_ptr) @ 0x0000000015efc18a 23. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001624c1b2 24. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000162f9c70 25. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x00000000162fa55a 26. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc6653 27. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000000fccc4c3 28. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc3d92 29. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fcca080 30. ? @ 0x00007fbc6213eac3 31. ? @ 0x00007fbc621d0850 (version 25.3.6.10636.altinitytest (altinity build)) 2025.07.28 11:58:42.542763 [ 5112 ] {043ab3bf-93f9-4a18-a18d-4aadd754c7da} executeQuery: Code: 60. DB::Exception: Table test_15.concurrent_optimize_table does not exist. (UNKNOWN_TABLE) (version 25.3.6.10636.altinitytest (altinity build)) (from [::1]:51088) (comment: 01103_optimize_drop_race_zookeeper.sh) (query 1, line 1) (in query: OPTIMIZE TABLE concurrent_optimize_table FINAL), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000a06a8eb 4. /build/src/Databases/IDatabase.cpp:41: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x0000000013dd565f 5. /build/src/Interpreters/DatabaseCatalog.cpp:442: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x00000000144f0869 6. /build/src/Interpreters/DatabaseCatalog.cpp:976: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x00000000144f6c88 7. /build/src/Interpreters/InterpreterOptimizeQuery.cpp:40: DB::InterpreterOptimizeQuery::execute() @ 0x0000000014cd71de 8. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88dc9 9. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 10. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 11. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 12. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 13. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 14. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 15. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 16. ? @ 0x00007fbc6213eac3 17. ? @ 0x00007fbc621d0850 2025.07.28 11:58:42.560089 [ 5112 ] {} TCPHandler: Code: 60. DB::Exception: Table test_15.concurrent_optimize_table does not exist. (UNKNOWN_TABLE), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000a06a8eb 4. /build/src/Databases/IDatabase.cpp:41: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x0000000013dd565f 5. /build/src/Interpreters/DatabaseCatalog.cpp:442: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x00000000144f0869 6. /build/src/Interpreters/DatabaseCatalog.cpp:976: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x00000000144f6c88 7. /build/src/Interpreters/InterpreterOptimizeQuery.cpp:40: DB::InterpreterOptimizeQuery::execute() @ 0x0000000014cd71de 8. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88dc9 9. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 10. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 11. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 12. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 13. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 14. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 15. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 16. ? @ 0x00007fbc6213eac3 17. ? @ 0x00007fbc621d0850 2025.07.28 11:58:42.601520 [ 17243 ] {de49f7b9-3ff6-4ff0-8808-aedfea6d9396} executeQuery: Code: 60. DB::Exception: Table test_15.concurrent_optimize_table does not exist. (UNKNOWN_TABLE) (version 25.3.6.10636.altinitytest (altinity build)) (from [::1]:51108) (comment: 01103_optimize_drop_race_zookeeper.sh) (query 1, line 1) (in query: INSERT INTO concurrent_optimize_table SELECT rand(1), rand(2), 1 / rand(3), toString(rand(4)), [rand(5), rand(6)], rand(7) % 2 ? NULL : generateUUIDv4(), (rand(8), rand(9)) FROM numbers(10000)), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000a06a8eb 4. /build/src/Databases/IDatabase.cpp:41: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x0000000013dd565f 5. /build/src/Interpreters/DatabaseCatalog.cpp:442: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x00000000144f0869 6. /build/src/Interpreters/DatabaseCatalog.cpp:976: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x00000000144f6c88 7. /build/src/Interpreters/InterpreterInsertQuery.cpp:169: DB::InterpreterInsertQuery::getTable(DB::ASTInsertQuery&) @ 0x000000001492bf04 8. /build/src/Interpreters/InterpreterInsertQuery.cpp:829: DB::InterpreterInsertQuery::execute() @ 0x0000000014933938 9. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88dc9 10. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 11. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 12. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 13. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 14. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 16. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 17. ? @ 0x00007fbc6213eac3 18. ? @ 0x00007fbc621d0850 2025.07.28 11:58:42.623704 [ 17611 ] {15b6d587-9bde-4b24-b443-7f899fe07f4f} executeQuery: Code: 60. DB::Exception: Table test_15.concurrent_optimize_table does not exist. (UNKNOWN_TABLE) (version 25.3.6.10636.altinitytest (altinity build)) (from [::1]:51120) (comment: 01103_optimize_drop_race_zookeeper.sh) (query 1, line 1) (in query: INSERT INTO concurrent_optimize_table SELECT rand(1), rand(2), 1 / rand(3), toString(rand(4)), [rand(5), rand(6)], rand(7) % 2 ? NULL : generateUUIDv4(), (rand(8), rand(9)) FROM numbers(10000)), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000a06a8eb 4. /build/src/Databases/IDatabase.cpp:41: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x0000000013dd565f 5. /build/src/Interpreters/DatabaseCatalog.cpp:442: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x00000000144f0869 6. /build/src/Interpreters/DatabaseCatalog.cpp:976: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x00000000144f6c88 7. /build/src/Interpreters/InterpreterInsertQuery.cpp:169: DB::InterpreterInsertQuery::getTable(DB::ASTInsertQuery&) @ 0x000000001492bf04 8. /build/src/Interpreters/InterpreterInsertQuery.cpp:829: DB::InterpreterInsertQuery::execute() @ 0x0000000014933938 9. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88dc9 10. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 11. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 12. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 13. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 14. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 16. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 17. ? @ 0x00007fbc6213eac3 18. ? @ 0x00007fbc621d0850 2025.07.28 11:58:42.631745 [ 17243 ] {} TCPHandler: Code: 60. DB::Exception: Table test_15.concurrent_optimize_table does not exist. (UNKNOWN_TABLE), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000a06a8eb 4. /build/src/Databases/IDatabase.cpp:41: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x0000000013dd565f 5. /build/src/Interpreters/DatabaseCatalog.cpp:442: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x00000000144f0869 6. /build/src/Interpreters/DatabaseCatalog.cpp:976: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x00000000144f6c88 7. /build/src/Interpreters/InterpreterInsertQuery.cpp:169: DB::InterpreterInsertQuery::getTable(DB::ASTInsertQuery&) @ 0x000000001492bf04 8. /build/src/Interpreters/InterpreterInsertQuery.cpp:829: DB::InterpreterInsertQuery::execute() @ 0x0000000014933938 9. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88dc9 10. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 11. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 12. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 13. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 14. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 16. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 17. ? @ 0x00007fbc6213eac3 18. ? @ 0x00007fbc621d0850 2025.07.28 11:58:42.664007 [ 17611 ] {} TCPHandler: Code: 60. DB::Exception: Table test_15.concurrent_optimize_table does not exist. (UNKNOWN_TABLE), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000a06a8eb 4. /build/src/Databases/IDatabase.cpp:41: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x0000000013dd565f 5. /build/src/Interpreters/DatabaseCatalog.cpp:442: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x00000000144f0869 6. /build/src/Interpreters/DatabaseCatalog.cpp:976: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x00000000144f6c88 7. /build/src/Interpreters/InterpreterInsertQuery.cpp:169: DB::InterpreterInsertQuery::getTable(DB::ASTInsertQuery&) @ 0x000000001492bf04 8. /build/src/Interpreters/InterpreterInsertQuery.cpp:829: DB::InterpreterInsertQuery::execute() @ 0x0000000014933938 9. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88dc9 10. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 11. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 12. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 13. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 14. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 16. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 17. ? @ 0x00007fbc6213eac3 18. ? @ 0x00007fbc621d0850 2025.07.28 11:58:42.714860 [ 17270 ] {0a4fa436-7d1e-4cdd-a640-48fa620a0e8a} executeQuery: Code: 60. DB::Exception: Table test_15.concurrent_optimize_table does not exist. (UNKNOWN_TABLE) (version 25.3.6.10636.altinitytest (altinity build)) (from [::1]:51134) (comment: 01103_optimize_drop_race_zookeeper.sh) (query 1, line 1) (in query: INSERT INTO concurrent_optimize_table SELECT rand(1), rand(2), 1 / rand(3), toString(rand(4)), [rand(5), rand(6)], rand(7) % 2 ? NULL : generateUUIDv4(), (rand(8), rand(9)) FROM numbers(10000)), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000a06a8eb 4. /build/src/Databases/IDatabase.cpp:41: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x0000000013dd565f 5. /build/src/Interpreters/DatabaseCatalog.cpp:442: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x00000000144f0869 6. /build/src/Interpreters/DatabaseCatalog.cpp:976: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x00000000144f6c88 7. /build/src/Interpreters/InterpreterInsertQuery.cpp:169: DB::InterpreterInsertQuery::getTable(DB::ASTInsertQuery&) @ 0x000000001492bf04 8. /build/src/Interpreters/InterpreterInsertQuery.cpp:829: DB::InterpreterInsertQuery::execute() @ 0x0000000014933938 9. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88dc9 10. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 11. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 12. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 13. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 14. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 16. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 17. ? @ 0x00007fbc6213eac3 18. ? @ 0x00007fbc621d0850 2025.07.28 11:58:42.728502 [ 17270 ] {} TCPHandler: Code: 60. DB::Exception: Table test_15.concurrent_optimize_table does not exist. (UNKNOWN_TABLE), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000a06a8eb 4. /build/src/Databases/IDatabase.cpp:41: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x0000000013dd565f 5. /build/src/Interpreters/DatabaseCatalog.cpp:442: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x00000000144f0869 6. /build/src/Interpreters/DatabaseCatalog.cpp:976: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x00000000144f6c88 7. /build/src/Interpreters/InterpreterInsertQuery.cpp:169: DB::InterpreterInsertQuery::getTable(DB::ASTInsertQuery&) @ 0x000000001492bf04 8. /build/src/Interpreters/InterpreterInsertQuery.cpp:829: DB::InterpreterInsertQuery::execute() @ 0x0000000014933938 9. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88dc9 10. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 11. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 12. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 13. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 14. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 16. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 17. ? @ 0x00007fbc6213eac3 18. ? @ 0x00007fbc621d0850 2025.07.28 11:58:42.978658 [ 17270 ] {9a1cfabe-8bde-49c1-b2ea-a42c097b9d4b} executeQuery: Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01103_optimize_drop_race_zookeeper_test_15/concurrent_optimize_table/replicas/1). (TABLE_IS_READ_ONLY) (version 25.3.6.10636.altinitytest (altinity build)) (from [::1]:51166) (comment: 01103_optimize_drop_race_zookeeper.sh) (query 1, line 1) (in query: OPTIMIZE TABLE concurrent_optimize_table FINAL), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000a9b78ab 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:5935: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000015e86144 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:6112: DB::StorageReplicatedMergeTree::optimize(std::shared_ptr const&, std::shared_ptr const&, std::shared_ptr const&, bool, bool, std::vector> const&, bool, std::shared_ptr) @ 0x0000000015f21f2c 6. /build/src/Interpreters/InterpreterOptimizeQuery.cpp:84: DB::InterpreterOptimizeQuery::execute() @ 0x0000000014cd782e 7. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88dc9 8. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 9. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 10. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 11. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 12. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 13. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 14. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 15. ? @ 0x00007fbc6213eac3 16. ? @ 0x00007fbc621d0850 2025.07.28 11:58:43.001430 [ 17270 ] {} TCPHandler: Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01103_optimize_drop_race_zookeeper_test_15/concurrent_optimize_table/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000a9b78ab 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:5935: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000015e86144 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:6112: DB::StorageReplicatedMergeTree::optimize(std::shared_ptr const&, std::shared_ptr const&, std::shared_ptr const&, bool, bool, std::vector> const&, bool, std::shared_ptr) @ 0x0000000015f21f2c 6. /build/src/Interpreters/InterpreterOptimizeQuery.cpp:84: DB::InterpreterOptimizeQuery::execute() @ 0x0000000014cd782e 7. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88dc9 8. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 9. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 10. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 11. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 12. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 13. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 14. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 15. ? @ 0x00007fbc6213eac3 16. ? @ 0x00007fbc621d0850 2025.07.28 11:58:43.128350 [ 17252 ] {1b339d8a-2d75-4217-a33d-357bf32c7ebe} executeQuery: Code: 57. DB::Exception: Table test_15.concurrent_optimize_table already exists. (TABLE_ALREADY_EXISTS) (version 25.3.6.10636.altinitytest (altinity build)) (from [::1]:39022) (comment: 01103_optimize_drop_race_zookeeper.sh) (query 2, line 2) (in query: CREATE TABLE concurrent_optimize_table (`a` UInt8, `b` Int16, `c` Float32, `d` String, `e` Array(UInt8), `f` Nullable(UUID), `g` Tuple(UInt8, UInt16)) ENGINE = ReplicatedMergeTree('/clickhouse/tables/01103_optimize_drop_race_zookeeper_test_15/concurrent_optimize_table', '1') PARTITION BY b % 10 ORDER BY a SETTINGS old_parts_lifetime = 1, cleanup_delay_period = 0, cleanup_delay_period_random_add = 0, cleanup_thread_preferred_points_per_iteration = 0, index_granularity = 31489, 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 = 20868213, compact_parts_max_bytes_to_buffer = 108362629, compact_parts_max_granules_to_buffer = 1, compact_parts_merge_max_bytes_to_prefetch_part = 18898448, merge_max_block_size = 13220, prefer_fetch_merged_part_size_threshold = 1, vertical_merge_algorithm_min_rows_to_activate = 1000000, vertical_merge_algorithm_min_columns_to_activate = 76, min_merge_bytes_to_use_direct_io = 10737418240, index_granularity_bytes = 7046892, use_const_adaptive_granularity = false, 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 = true, cache_populated_by_fetch = false, marks_compress_block_size = 84392, primary_key_compress_block_size = 23861, 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. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000a06a8eb 4. /build/src/Interpreters/InterpreterCreateQuery.cpp:1824: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x0000000014901d53 5. /build/src/Interpreters/InterpreterCreateQuery.cpp:1743: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000148f9aa9 6. /build/src/Interpreters/InterpreterCreateQuery.cpp:2352: DB::InterpreterCreateQuery::execute() @ 0x0000000014905a41 7. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88dc9 8. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 9. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 10. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 11. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 12. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 13. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 14. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 15. ? @ 0x00007fbc6213eac3 16. ? @ 0x00007fbc621d0850 2025.07.28 11:58:43.177455 [ 11826 ] {d83fd97f-bc42-45a2-8c6c-a17a7bd9f5da} executeQuery: Code: 57. DB::Exception: Table test_15.concurrent_optimize_table already exists. (TABLE_ALREADY_EXISTS) (version 25.3.6.10636.altinitytest (altinity build)) (from [::1]:38960) (comment: 01103_optimize_drop_race_zookeeper.sh) (query 2, line 2) (in query: CREATE TABLE concurrent_optimize_table (`a` UInt8, `b` Int16, `c` Float32, `d` String, `e` Array(UInt8), `f` Nullable(UUID), `g` Tuple(UInt8, UInt16)) ENGINE = ReplicatedMergeTree('/clickhouse/tables/01103_optimize_drop_race_zookeeper_test_15/concurrent_optimize_table', '1') PARTITION BY b % 10 ORDER BY a SETTINGS old_parts_lifetime = 1, cleanup_delay_period = 0, cleanup_delay_period_random_add = 0, cleanup_thread_preferred_points_per_iteration = 0, index_granularity = 31489, 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 = 20868213, compact_parts_max_bytes_to_buffer = 108362629, compact_parts_max_granules_to_buffer = 1, compact_parts_merge_max_bytes_to_prefetch_part = 18898448, merge_max_block_size = 13220, prefer_fetch_merged_part_size_threshold = 1, vertical_merge_algorithm_min_rows_to_activate = 1000000, vertical_merge_algorithm_min_columns_to_activate = 76, min_merge_bytes_to_use_direct_io = 10737418240, index_granularity_bytes = 7046892, use_const_adaptive_granularity = false, 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 = true, cache_populated_by_fetch = false, marks_compress_block_size = 84392, primary_key_compress_block_size = 23861, 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. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000a06a8eb 4. /build/src/Interpreters/InterpreterCreateQuery.cpp:1824: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x0000000014901d53 5. /build/src/Interpreters/InterpreterCreateQuery.cpp:1743: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000148f9aa9 6. /build/src/Interpreters/InterpreterCreateQuery.cpp:2352: DB::InterpreterCreateQuery::execute() @ 0x0000000014905a41 7. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88dc9 8. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 9. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 10. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 11. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 12. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 13. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 14. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 15. ? @ 0x00007fbc6213eac3 16. ? @ 0x00007fbc621d0850 2025.07.28 11:58:43.187635 [ 17252 ] {} TCPHandler: Code: 57. DB::Exception: Table test_15.concurrent_optimize_table already exists. (TABLE_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000a06a8eb 4. /build/src/Interpreters/InterpreterCreateQuery.cpp:1824: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x0000000014901d53 5. /build/src/Interpreters/InterpreterCreateQuery.cpp:1743: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000148f9aa9 6. /build/src/Interpreters/InterpreterCreateQuery.cpp:2352: DB::InterpreterCreateQuery::execute() @ 0x0000000014905a41 7. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88dc9 8. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 9. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 10. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 11. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 12. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 13. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 14. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 15. ? @ 0x00007fbc6213eac3 16. ? @ 0x00007fbc621d0850 2025.07.28 11:58:43.194807 [ 11826 ] {} TCPHandler: Code: 57. DB::Exception: Table test_15.concurrent_optimize_table already exists. (TABLE_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000a06a8eb 4. /build/src/Interpreters/InterpreterCreateQuery.cpp:1824: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x0000000014901d53 5. /build/src/Interpreters/InterpreterCreateQuery.cpp:1743: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000148f9aa9 6. /build/src/Interpreters/InterpreterCreateQuery.cpp:2352: DB::InterpreterCreateQuery::execute() @ 0x0000000014905a41 7. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88dc9 8. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 9. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 10. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 11. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 12. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 13. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 14. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 15. ? @ 0x00007fbc6213eac3 16. ? @ 0x00007fbc621d0850 2025.07.28 11:58:43.210314 [ 3977 ] {} test_13.rmt2 (7f9b740d-015c-470e-8cc6-8ba33be0dc63): auto DB::StorageReplicatedMergeTree::processQueueEntry(ReplicatedMergeTreeQueue::SelectedEntryPtr)::(anonymous class)::operator()(LogEntryPtr &) const: Code: 86. DB::HTTPException: Received error from remote server http://146b4357c08d:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Ftest%2F01165%2Ftest_13%2Frmt%2Freplicas%2F1&part=20250728_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.6.10636.altinitytest (altinity build)) '. (RECEIVED_ERROR_FROM_REMOTE_IO_SERVER), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.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 const&, int&&, String const&, unsigned long&&, String const&) @ 0x000000000feda8d9 4. /build/src/IO/HTTPCommon.cpp:104: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x000000000feda6e2 5. /build/src/IO/HTTPCommon.cpp:93: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x000000000feda537 6. /build/src/IO/ReadWriteBufferFromHTTP.cpp:277: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x000000001184a4c4 7. /build/src/IO/ReadWriteBufferFromHTTP.cpp:285: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x000000001184a615 8. /build/src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x000000001184ae59 9. /build/src/IO/ReadWriteBufferFromHTTP.cpp:472: void std::__function::__policy_invoker::__call_impl[abi:se190107]>(std::__function::__policy_storage const*) @ 0x000000001184cedd 10. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001184858b 11. /build/src/IO/ReadWriteBufferFromHTTP.cpp:465: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x000000001184bf0b 12. /build/src/IO/ReadBuffer.h:60: DB::ReadBuffer::next() @ 0x000000000a148c7b 13. /build/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) @ 0x0000000011849fb2 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]>&)>&, 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&) @ 0x0000000011841980 15. /build/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) @ 0x000000001621208e 16. /build/src/Storages/StorageReplicatedMergeTree.cpp:5228: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl[abi:se190107] const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000015f9a5fe 17. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000015ed8bfd 18. /build/src/Storages/StorageReplicatedMergeTree.cpp:2514: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x0000000015ec9aab 19. /build/src/Storages/StorageReplicatedMergeTree.cpp:2349: DB::StorageReplicatedMergeTree::executeLogEntry(DB::ReplicatedMergeTreeLogEntry&) @ 0x0000000015eba91b 20. /build/src/Storages/StorageReplicatedMergeTree.cpp:3876: bool std::__function::__policy_invoker&)>::__call_impl[abi:se190107])::$_1, bool (std::shared_ptr&)>>(std::__function::__policy_storage const*, std::shared_ptr&) @ 0x0000000015f9837e 21. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000165d6fc3 22. /build/src/Storages/StorageReplicatedMergeTree.cpp:3872: DB::StorageReplicatedMergeTree::processQueueEntry(std::shared_ptr) @ 0x0000000015efc18a 23. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001624c1b2 24. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000162f9c70 25. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x00000000162fa55a 26. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc6653 27. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000000fccc4c3 28. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc3d92 29. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fcca080 30. ? @ 0x00007fbc6213eac3 31. ? @ 0x00007fbc621d0850 (version 25.3.6.10636.altinitytest (altinity build)) 2025.07.28 11:58:43.219248 [ 4900 ] {d1aea888-06a6-4ee1-bc8f-51788722a91f} executeQuery: Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01103_optimize_drop_race_zookeeper_test_15/concurrent_optimize_table/replicas/1). (TABLE_IS_READ_ONLY) (version 25.3.6.10636.altinitytest (altinity build)) (from [::1]:51200) (comment: 01103_optimize_drop_race_zookeeper.sh) (query 1, line 1) (in query: OPTIMIZE TABLE concurrent_optimize_table FINAL), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000a9b78ab 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:5935: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000015e86144 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:6112: DB::StorageReplicatedMergeTree::optimize(std::shared_ptr const&, std::shared_ptr const&, std::shared_ptr const&, bool, bool, std::vector> const&, bool, std::shared_ptr) @ 0x0000000015f21f2c 6. /build/src/Interpreters/InterpreterOptimizeQuery.cpp:84: DB::InterpreterOptimizeQuery::execute() @ 0x0000000014cd782e 7. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88dc9 8. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 9. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 10. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 11. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 12. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 13. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 14. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 15. ? @ 0x00007fbc6213eac3 16. ? @ 0x00007fbc621d0850 2025.07.28 11:58:43.229288 [ 4900 ] {} TCPHandler: Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01103_optimize_drop_race_zookeeper_test_15/concurrent_optimize_table/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000a9b78ab 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:5935: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000015e86144 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:6112: DB::StorageReplicatedMergeTree::optimize(std::shared_ptr const&, std::shared_ptr const&, std::shared_ptr const&, bool, bool, std::vector> const&, bool, std::shared_ptr) @ 0x0000000015f21f2c 6. /build/src/Interpreters/InterpreterOptimizeQuery.cpp:84: DB::InterpreterOptimizeQuery::execute() @ 0x0000000014cd782e 7. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88dc9 8. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 9. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 10. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 11. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 12. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 13. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 14. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 15. ? @ 0x00007fbc6213eac3 16. ? @ 0x00007fbc621d0850 2025.07.28 11:58:43.349048 [ 17270 ] {e15de1c4-d9ba-40e2-9116-a70e81d73b94} executeQuery: Code: 60. DB::Exception: Table test_15.concurrent_optimize_table does not exist. (UNKNOWN_TABLE) (version 25.3.6.10636.altinitytest (altinity build)) (from [::1]:51202) (comment: 01103_optimize_drop_race_zookeeper.sh) (query 1, line 1) (in query: OPTIMIZE TABLE concurrent_optimize_table FINAL), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000a06a8eb 4. /build/src/Databases/IDatabase.cpp:41: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x0000000013dd565f 5. /build/src/Interpreters/DatabaseCatalog.cpp:442: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x00000000144f0869 6. /build/src/Interpreters/DatabaseCatalog.cpp:976: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x00000000144f6c88 7. /build/src/Interpreters/InterpreterOptimizeQuery.cpp:40: DB::InterpreterOptimizeQuery::execute() @ 0x0000000014cd71de 8. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88dc9 9. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 10. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 11. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 12. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 13. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 14. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 15. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 16. ? @ 0x00007fbc6213eac3 17. ? @ 0x00007fbc621d0850 2025.07.28 11:58:43.403021 [ 17270 ] {} TCPHandler: Code: 60. DB::Exception: Table test_15.concurrent_optimize_table does not exist. (UNKNOWN_TABLE), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000a06a8eb 4. /build/src/Databases/IDatabase.cpp:41: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x0000000013dd565f 5. /build/src/Interpreters/DatabaseCatalog.cpp:442: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x00000000144f0869 6. /build/src/Interpreters/DatabaseCatalog.cpp:976: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x00000000144f6c88 7. /build/src/Interpreters/InterpreterOptimizeQuery.cpp:40: DB::InterpreterOptimizeQuery::execute() @ 0x0000000014cd71de 8. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88dc9 9. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 10. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 11. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 12. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 13. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 14. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 15. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 16. ? @ 0x00007fbc6213eac3 17. ? @ 0x00007fbc621d0850 2025.07.28 11:58:43.425762 [ 3967 ] {} test_13.rmt2 (7f9b740d-015c-470e-8cc6-8ba33be0dc63): auto DB::StorageReplicatedMergeTree::processQueueEntry(ReplicatedMergeTreeQueue::SelectedEntryPtr)::(anonymous class)::operator()(LogEntryPtr &) const: Code: 86. DB::HTTPException: Received error from remote server http://146b4357c08d:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Ftest%2F01165%2Ftest_13%2Frmt%2Freplicas%2F1&part=20250728_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.6.10636.altinitytest (altinity build)) '. (RECEIVED_ERROR_FROM_REMOTE_IO_SERVER), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.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 const&, int&&, String const&, unsigned long&&, String const&) @ 0x000000000feda8d9 4. /build/src/IO/HTTPCommon.cpp:104: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x000000000feda6e2 5. /build/src/IO/HTTPCommon.cpp:93: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x000000000feda537 6. /build/src/IO/ReadWriteBufferFromHTTP.cpp:277: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x000000001184a4c4 7. /build/src/IO/ReadWriteBufferFromHTTP.cpp:285: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x000000001184a615 8. /build/src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x000000001184ae59 9. /build/src/IO/ReadWriteBufferFromHTTP.cpp:472: void std::__function::__policy_invoker::__call_impl[abi:se190107]>(std::__function::__policy_storage const*) @ 0x000000001184cedd 10. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001184858b 11. /build/src/IO/ReadWriteBufferFromHTTP.cpp:465: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x000000001184bf0b 12. /build/src/IO/ReadBuffer.h:60: DB::ReadBuffer::next() @ 0x000000000a148c7b 13. /build/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) @ 0x0000000011849fb2 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]>&)>&, 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&) @ 0x0000000011841980 15. /build/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) @ 0x000000001621208e 16. /build/src/Storages/StorageReplicatedMergeTree.cpp:5228: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl[abi:se190107] const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000015f9a5fe 17. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000015ed8bfd 18. /build/src/Storages/StorageReplicatedMergeTree.cpp:2514: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x0000000015ec9aab 19. /build/src/Storages/StorageReplicatedMergeTree.cpp:2349: DB::StorageReplicatedMergeTree::executeLogEntry(DB::ReplicatedMergeTreeLogEntry&) @ 0x0000000015eba91b 20. /build/src/Storages/StorageReplicatedMergeTree.cpp:3876: bool std::__function::__policy_invoker&)>::__call_impl[abi:se190107])::$_1, bool (std::shared_ptr&)>>(std::__function::__policy_storage const*, std::shared_ptr&) @ 0x0000000015f9837e 21. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000165d6fc3 22. /build/src/Storages/StorageReplicatedMergeTree.cpp:3872: DB::StorageReplicatedMergeTree::processQueueEntry(std::shared_ptr) @ 0x0000000015efc18a 23. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001624c1b2 24. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000162f9c70 25. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x00000000162fa55a 26. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc6653 27. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000000fccc4c3 28. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc3d92 29. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fcca080 30. ? @ 0x00007fbc6213eac3 31. ? @ 0x00007fbc621d0850 (version 25.3.6.10636.altinitytest (altinity build)) 2025.07.28 11:58:43.487092 [ 4900 ] {eb303478-dd42-4f0b-a25e-c7abd0e1960d} executeQuery: Code: 60. DB::Exception: Table test_15.concurrent_optimize_table does not exist. (UNKNOWN_TABLE) (version 25.3.6.10636.altinitytest (altinity build)) (from [::1]:51224) (comment: 01103_optimize_drop_race_zookeeper.sh) (query 1, line 1) (in query: OPTIMIZE TABLE concurrent_optimize_table FINAL), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000a06a8eb 4. /build/src/Databases/IDatabase.cpp:41: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x0000000013dd565f 5. /build/src/Interpreters/DatabaseCatalog.cpp:442: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x00000000144f0869 6. /build/src/Interpreters/DatabaseCatalog.cpp:976: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x00000000144f6c88 7. /build/src/Interpreters/InterpreterOptimizeQuery.cpp:40: DB::InterpreterOptimizeQuery::execute() @ 0x0000000014cd71de 8. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88dc9 9. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 10. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 11. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 12. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 13. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 14. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 15. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 16. ? @ 0x00007fbc6213eac3 17. ? @ 0x00007fbc621d0850 2025.07.28 11:58:43.497184 [ 4900 ] {} TCPHandler: Code: 60. DB::Exception: Table test_15.concurrent_optimize_table does not exist. (UNKNOWN_TABLE), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000a06a8eb 4. /build/src/Databases/IDatabase.cpp:41: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x0000000013dd565f 5. /build/src/Interpreters/DatabaseCatalog.cpp:442: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x00000000144f0869 6. /build/src/Interpreters/DatabaseCatalog.cpp:976: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x00000000144f6c88 7. /build/src/Interpreters/InterpreterOptimizeQuery.cpp:40: DB::InterpreterOptimizeQuery::execute() @ 0x0000000014cd71de 8. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88dc9 9. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 10. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 11. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 12. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 13. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 14. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 15. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 16. ? @ 0x00007fbc6213eac3 17. ? @ 0x00007fbc621d0850 2025.07.28 11:58:43.616471 [ 17270 ] {e067f8e3-b992-494a-b6c1-62c26bb0588b} executeQuery: Code: 60. DB::Exception: Table test_15.concurrent_optimize_table does not exist. (UNKNOWN_TABLE) (version 25.3.6.10636.altinitytest (altinity build)) (from [::1]:51236) (comment: 01103_optimize_drop_race_zookeeper.sh) (query 1, line 1) (in query: OPTIMIZE TABLE concurrent_optimize_table FINAL), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000a06a8eb 4. /build/src/Databases/IDatabase.cpp:41: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x0000000013dd565f 5. /build/src/Interpreters/DatabaseCatalog.cpp:442: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x00000000144f0869 6. /build/src/Interpreters/DatabaseCatalog.cpp:976: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x00000000144f6c88 7. /build/src/Interpreters/InterpreterOptimizeQuery.cpp:40: DB::InterpreterOptimizeQuery::execute() @ 0x0000000014cd71de 8. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88dc9 9. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 10. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 11. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 12. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 13. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 14. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 15. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 16. ? @ 0x00007fbc6213eac3 17. ? @ 0x00007fbc621d0850 2025.07.28 11:58:43.635492 [ 17270 ] {} TCPHandler: Code: 60. DB::Exception: Table test_15.concurrent_optimize_table does not exist. (UNKNOWN_TABLE), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000a06a8eb 4. /build/src/Databases/IDatabase.cpp:41: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x0000000013dd565f 5. /build/src/Interpreters/DatabaseCatalog.cpp:442: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x00000000144f0869 6. /build/src/Interpreters/DatabaseCatalog.cpp:976: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x00000000144f6c88 7. /build/src/Interpreters/InterpreterOptimizeQuery.cpp:40: DB::InterpreterOptimizeQuery::execute() @ 0x0000000014cd71de 8. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88dc9 9. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 10. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 11. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 12. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 13. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 14. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 15. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 16. ? @ 0x00007fbc6213eac3 17. ? @ 0x00007fbc621d0850 2025.07.28 11:58:43.837066 [ 17270 ] {4dd0e9b0-ec48-4d53-a541-1ae0927edd41} executeQuery: Code: 60. DB::Exception: Table test_15.concurrent_optimize_table does not exist. (UNKNOWN_TABLE) (version 25.3.6.10636.altinitytest (altinity build)) (from [::1]:51258) (comment: 01103_optimize_drop_race_zookeeper.sh) (query 1, line 1) (in query: OPTIMIZE TABLE concurrent_optimize_table FINAL), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000a06a8eb 4. /build/src/Databases/IDatabase.cpp:41: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x0000000013dd565f 5. /build/src/Interpreters/DatabaseCatalog.cpp:442: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x00000000144f0869 6. /build/src/Interpreters/DatabaseCatalog.cpp:976: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x00000000144f6c88 7. /build/src/Interpreters/InterpreterOptimizeQuery.cpp:40: DB::InterpreterOptimizeQuery::execute() @ 0x0000000014cd71de 8. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88dc9 9. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 10. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 11. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 12. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 13. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 14. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 15. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 16. ? @ 0x00007fbc6213eac3 17. ? @ 0x00007fbc621d0850 2025.07.28 11:58:43.850547 [ 7630 ] {6282fba4-2f3c-4ed4-b48b-5148f53c0a25} executeQuery: Code: 242. DB::Exception: Table is in readonly mode due to shutdown: replica_path=/clickhouse/tables/01103_optimize_drop_race_zookeeper_test_15/concurrent_optimize_table/replicas/1. (TABLE_IS_READ_ONLY) (version 25.3.6.10636.altinitytest (altinity build)) (from [::1]:51178) (comment: 01103_optimize_drop_race_zookeeper.sh) (query 1, line 1) (in query: INSERT INTO concurrent_optimize_table SELECT rand(1), rand(2), 1 / rand(3), toString(rand(4)), [rand(5), rand(6)], rand(7) % 2 ? NULL : generateUUIDv4(), (rand(8), rand(9)) FROM numbers(10000)), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000a9b78ab 4. /build/src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:866: DB::ReplicatedMergeTreeSinkImpl::commitPart(std::shared_ptr const&, std::shared_ptr&, String const&, unsigned long)::'lambda1'()::operator()() const @ 0x000000001660eed7 5. /build/src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:1124: DB::ReplicatedMergeTreeSinkImpl::commitPart(std::shared_ptr const&, std::shared_ptr&, String const&, unsigned long)::'lambda2'()::operator()() const @ 0x000000001660d1f2 6. /build/src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:1157: void DB::ZooKeeperRetriesControl::retryLoop::commitPart(std::shared_ptr const&, std::shared_ptr&, String const&, unsigned long)::'lambda3'()&, void DB::ZooKeeperRetriesControl::retryLoop::commitPart(std::shared_ptr const&, std::shared_ptr&, String const&, unsigned long)::'lambda3'()>(DB::ReplicatedMergeTreeSinkImpl::commitPart(std::shared_ptr const&, std::shared_ptr&, String const&, unsigned long)::'lambda3'()&&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::commitPart(std::shared_ptr const&, std::shared_ptr&, String const&, unsigned long)::'lambda3'()&&, void DB::ZooKeeperRetriesControl::retryLoop::commitPart(std::shared_ptr const&, std::shared_ptr&, String const&, unsigned long)::'lambda3'()>(DB::ReplicatedMergeTreeSinkImpl::commitPart(std::shared_ptr const&, std::shared_ptr&, String const&, unsigned long)::'lambda3'()&&)::'lambda'()&&) @ 0x000000001660d07f 7. /build/src/Common/ZooKeeper/ZooKeeperRetries.h:52: DB::ReplicatedMergeTreeSinkImpl::commitPart(std::shared_ptr const&, std::shared_ptr&, String const&, unsigned long) @ 0x00000000165fd951 8. /build/src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:492: DB::ReplicatedMergeTreeSinkImpl::finishDelayedChunk(std::shared_ptr const&) @ 0x00000000165f277d 9. /build/src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:437: DB::ReplicatedMergeTreeSinkImpl::consume(DB::Chunk&) @ 0x00000000165fbd00 10. /build/src/Processors/Sinks/SinkToStorage.cpp:10: DB::SinkToStorage::onConsume(DB::Chunk) @ 0x0000000016cee093 11. /build/src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: void std::__function::__policy_invoker::__call_impl[abi:se190107]>(std::__function::__policy_storage const*) @ 0x0000000016c0ad89 12. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000016c0abf5 13. /build/src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: DB::ExceptionKeepingTransform::work() @ 0x0000000016c0a6fe 14. /build/src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x00000000169bd00f 15. /build/src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x00000000169b2105 16. /build/src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeSingleThread(unsigned long) @ 0x00000000169b23be 17. /build/src/Processors/Executors/PipelineExecutor.cpp:416: void std::__function::__policy_invoker::__call_impl[abi:se190107]>(std::__function::__policy_storage const*) @ 0x00000000169b2e3f 18. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc6653 19. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000000fccc4c3 20. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc3d92 21. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fcca080 22. ? @ 0x00007fbc6213eac3 23. ? @ 0x00007fbc621d0850 2025.07.28 11:58:43.869402 [ 17270 ] {} TCPHandler: Code: 60. DB::Exception: Table test_15.concurrent_optimize_table does not exist. (UNKNOWN_TABLE), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000a06a8eb 4. /build/src/Databases/IDatabase.cpp:41: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x0000000013dd565f 5. /build/src/Interpreters/DatabaseCatalog.cpp:442: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x00000000144f0869 6. /build/src/Interpreters/DatabaseCatalog.cpp:976: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x00000000144f6c88 7. /build/src/Interpreters/InterpreterOptimizeQuery.cpp:40: DB::InterpreterOptimizeQuery::execute() @ 0x0000000014cd71de 8. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88dc9 9. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 10. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 11. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 12. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 13. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 14. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 15. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 16. ? @ 0x00007fbc6213eac3 17. ? @ 0x00007fbc621d0850 2025.07.28 11:58:43.882804 [ 7630 ] {} TCPHandler: Code: 242. DB::Exception: Table is in readonly mode due to shutdown: replica_path=/clickhouse/tables/01103_optimize_drop_race_zookeeper_test_15/concurrent_optimize_table/replicas/1. (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000a9b78ab 4. /build/src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:866: DB::ReplicatedMergeTreeSinkImpl::commitPart(std::shared_ptr const&, std::shared_ptr&, String const&, unsigned long)::'lambda1'()::operator()() const @ 0x000000001660eed7 5. /build/src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:1124: DB::ReplicatedMergeTreeSinkImpl::commitPart(std::shared_ptr const&, std::shared_ptr&, String const&, unsigned long)::'lambda2'()::operator()() const @ 0x000000001660d1f2 6. /build/src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:1157: void DB::ZooKeeperRetriesControl::retryLoop::commitPart(std::shared_ptr const&, std::shared_ptr&, String const&, unsigned long)::'lambda3'()&, void DB::ZooKeeperRetriesControl::retryLoop::commitPart(std::shared_ptr const&, std::shared_ptr&, String const&, unsigned long)::'lambda3'()>(DB::ReplicatedMergeTreeSinkImpl::commitPart(std::shared_ptr const&, std::shared_ptr&, String const&, unsigned long)::'lambda3'()&&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::commitPart(std::shared_ptr const&, std::shared_ptr&, String const&, unsigned long)::'lambda3'()&&, void DB::ZooKeeperRetriesControl::retryLoop::commitPart(std::shared_ptr const&, std::shared_ptr&, String const&, unsigned long)::'lambda3'()>(DB::ReplicatedMergeTreeSinkImpl::commitPart(std::shared_ptr const&, std::shared_ptr&, String const&, unsigned long)::'lambda3'()&&)::'lambda'()&&) @ 0x000000001660d07f 7. /build/src/Common/ZooKeeper/ZooKeeperRetries.h:52: DB::ReplicatedMergeTreeSinkImpl::commitPart(std::shared_ptr const&, std::shared_ptr&, String const&, unsigned long) @ 0x00000000165fd951 8. /build/src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:492: DB::ReplicatedMergeTreeSinkImpl::finishDelayedChunk(std::shared_ptr const&) @ 0x00000000165f277d 9. /build/src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:437: DB::ReplicatedMergeTreeSinkImpl::consume(DB::Chunk&) @ 0x00000000165fbd00 10. /build/src/Processors/Sinks/SinkToStorage.cpp:10: DB::SinkToStorage::onConsume(DB::Chunk) @ 0x0000000016cee093 11. /build/src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: void std::__function::__policy_invoker::__call_impl[abi:se190107]>(std::__function::__policy_storage const*) @ 0x0000000016c0ad89 12. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000016c0abf5 13. /build/src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: DB::ExceptionKeepingTransform::work() @ 0x0000000016c0a6fe 14. /build/src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x00000000169bd00f 15. /build/src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x00000000169b2105 16. /build/src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeSingleThread(unsigned long) @ 0x00000000169b23be 17. /build/src/Processors/Executors/PipelineExecutor.cpp:416: void std::__function::__policy_invoker::__call_impl[abi:se190107]>(std::__function::__policy_storage const*) @ 0x00000000169b2e3f 18. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc6653 19. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000000fccc4c3 20. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc3d92 21. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fcca080 22. ? @ 0x00007fbc6213eac3 23. ? @ 0x00007fbc621d0850 Job's origin stack trace: 0. /build/src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000000fc33b84 1. /build/src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000000fcc2ea7 2. /build/src/Common/ThreadPool.cpp:401: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fcc7f1c 3. /build/src/Common/ThreadPool.cpp:494: ThreadPoolImpl>::scheduleOrThrowOnError(std::function, Priority) @ 0x000000000fcc7a0e 4. /build/src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::spawnThreadsImpl() @ 0x00000000169b2c0c 5. /build/src/Processors/Executors/PipelineExecutor.cpp:394: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x00000000169b0ba7 6. /build/src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x00000000169b03f4 7. /build/src/Processors/Executors/CompletedPipelineExecutor.cpp:42: void std::__function::__policy_invoker::__call_impl[abi:se190107]::ThreadFromGlobalPoolImpl(DB::CompletedPipelineExecutor::execute()::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169af7e1 8. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc3d92 9. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fcca080 10. ? @ 0x00007fbc6213eac3 11. ? @ 0x00007fbc621d0850 Job's origin stack trace: 0. /build/src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000000fc33b84 1. /build/src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000000fcc2ea7 2. /build/src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fcc535c 3. /build/src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000000fcc584d 4. /build/src/Common/ThreadPool.h:279: DB::CompletedPipelineExecutor::execute() @ 0x00000000169af267 5. /build/src/Server/TCPHandler.cpp:707: DB::TCPHandler::runImpl() @ 0x00000000168e6b2e 6. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 7. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 8. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 9. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 10. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 11. ? @ 0x00007fbc6213eac3 12. ? @ 0x00007fbc621d0850 2025.07.28 11:58:43.885987 [ 5112 ] {66152949-91a9-4355-af43-a017b6b2ad97} executeQuery: Code: 242. DB::Exception: Table is in readonly mode due to shutdown: replica_path=/clickhouse/tables/01103_optimize_drop_race_zookeeper_test_15/concurrent_optimize_table/replicas/1. (TABLE_IS_READ_ONLY) (version 25.3.6.10636.altinitytest (altinity build)) (from [::1]:51146) (comment: 01103_optimize_drop_race_zookeeper.sh) (query 1, line 1) (in query: INSERT INTO concurrent_optimize_table SELECT rand(1), rand(2), 1 / rand(3), toString(rand(4)), [rand(5), rand(6)], rand(7) % 2 ? NULL : generateUUIDv4(), (rand(8), rand(9)) FROM numbers(10000)), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000a9b78ab 4. /build/src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:866: DB::ReplicatedMergeTreeSinkImpl::commitPart(std::shared_ptr const&, std::shared_ptr&, String const&, unsigned long)::'lambda1'()::operator()() const @ 0x000000001660eed7 5. /build/src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:1124: DB::ReplicatedMergeTreeSinkImpl::commitPart(std::shared_ptr const&, std::shared_ptr&, String const&, unsigned long)::'lambda2'()::operator()() const @ 0x000000001660d1f2 6. /build/src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:1157: void DB::ZooKeeperRetriesControl::retryLoop::commitPart(std::shared_ptr const&, std::shared_ptr&, String const&, unsigned long)::'lambda3'()&, void DB::ZooKeeperRetriesControl::retryLoop::commitPart(std::shared_ptr const&, std::shared_ptr&, String const&, unsigned long)::'lambda3'()>(DB::ReplicatedMergeTreeSinkImpl::commitPart(std::shared_ptr const&, std::shared_ptr&, String const&, unsigned long)::'lambda3'()&&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::commitPart(std::shared_ptr const&, std::shared_ptr&, String const&, unsigned long)::'lambda3'()&&, void DB::ZooKeeperRetriesControl::retryLoop::commitPart(std::shared_ptr const&, std::shared_ptr&, String const&, unsigned long)::'lambda3'()>(DB::ReplicatedMergeTreeSinkImpl::commitPart(std::shared_ptr const&, std::shared_ptr&, String const&, unsigned long)::'lambda3'()&&)::'lambda'()&&) @ 0x000000001660d07f 7. /build/src/Common/ZooKeeper/ZooKeeperRetries.h:52: DB::ReplicatedMergeTreeSinkImpl::commitPart(std::shared_ptr const&, std::shared_ptr&, String const&, unsigned long) @ 0x00000000165fd951 8. /build/src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:492: DB::ReplicatedMergeTreeSinkImpl::finishDelayedChunk(std::shared_ptr const&) @ 0x00000000165f277d 9. /build/src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:437: DB::ReplicatedMergeTreeSinkImpl::consume(DB::Chunk&) @ 0x00000000165fbd00 10. /build/src/Processors/Sinks/SinkToStorage.cpp:10: DB::SinkToStorage::onConsume(DB::Chunk) @ 0x0000000016cee093 11. /build/src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: void std::__function::__policy_invoker::__call_impl[abi:se190107]>(std::__function::__policy_storage const*) @ 0x0000000016c0ad89 12. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000016c0abf5 13. /build/src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: DB::ExceptionKeepingTransform::work() @ 0x0000000016c0a6fe 14. /build/src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x00000000169bd00f 15. /build/src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x00000000169b2105 16. /build/src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeSingleThread(unsigned long) @ 0x00000000169b23be 17. /build/src/Processors/Executors/PipelineExecutor.cpp:416: void std::__function::__policy_invoker::__call_impl[abi:se190107]>(std::__function::__policy_storage const*) @ 0x00000000169b2e3f 18. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc6653 19. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000000fccc4c3 20. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc3d92 21. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fcca080 22. ? @ 0x00007fbc6213eac3 23. ? @ 0x00007fbc621d0850 2025.07.28 11:58:43.892165 [ 4963 ] {15eaa9f8-2d73-4bc3-8678-546401db425e} executeQuery: Code: 60. DB::Exception: Table test_15.concurrent_optimize_table does not exist. (UNKNOWN_TABLE) (version 25.3.6.10636.altinitytest (altinity build)) (from [::1]:51264) (comment: 01103_optimize_drop_race_zookeeper.sh) (query 1, line 1) (in query: OPTIMIZE TABLE concurrent_optimize_table FINAL), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000a06a8eb 4. /build/src/Databases/IDatabase.cpp:41: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x0000000013dd565f 5. /build/src/Interpreters/DatabaseCatalog.cpp:442: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x00000000144f0869 6. /build/src/Interpreters/DatabaseCatalog.cpp:976: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x00000000144f6c88 7. /build/src/Interpreters/InterpreterOptimizeQuery.cpp:40: DB::InterpreterOptimizeQuery::execute() @ 0x0000000014cd71de 8. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88dc9 9. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 10. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 11. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 12. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 13. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 14. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 15. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 16. ? @ 0x00007fbc6213eac3 17. ? @ 0x00007fbc621d0850 2025.07.28 11:58:43.904224 [ 4963 ] {} TCPHandler: Code: 60. DB::Exception: Table test_15.concurrent_optimize_table does not exist. (UNKNOWN_TABLE), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000a06a8eb 4. /build/src/Databases/IDatabase.cpp:41: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x0000000013dd565f 5. /build/src/Interpreters/DatabaseCatalog.cpp:442: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x00000000144f0869 6. /build/src/Interpreters/DatabaseCatalog.cpp:976: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x00000000144f6c88 7. /build/src/Interpreters/InterpreterOptimizeQuery.cpp:40: DB::InterpreterOptimizeQuery::execute() @ 0x0000000014cd71de 8. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88dc9 9. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 10. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 11. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 12. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 13. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 14. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 15. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 16. ? @ 0x00007fbc6213eac3 17. ? @ 0x00007fbc621d0850 2025.07.28 11:58:43.924837 [ 5112 ] {} TCPHandler: Code: 242. DB::Exception: Table is in readonly mode due to shutdown: replica_path=/clickhouse/tables/01103_optimize_drop_race_zookeeper_test_15/concurrent_optimize_table/replicas/1. (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000a9b78ab 4. /build/src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:866: DB::ReplicatedMergeTreeSinkImpl::commitPart(std::shared_ptr const&, std::shared_ptr&, String const&, unsigned long)::'lambda1'()::operator()() const @ 0x000000001660eed7 5. /build/src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:1124: DB::ReplicatedMergeTreeSinkImpl::commitPart(std::shared_ptr const&, std::shared_ptr&, String const&, unsigned long)::'lambda2'()::operator()() const @ 0x000000001660d1f2 6. /build/src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:1157: void DB::ZooKeeperRetriesControl::retryLoop::commitPart(std::shared_ptr const&, std::shared_ptr&, String const&, unsigned long)::'lambda3'()&, void DB::ZooKeeperRetriesControl::retryLoop::commitPart(std::shared_ptr const&, std::shared_ptr&, String const&, unsigned long)::'lambda3'()>(DB::ReplicatedMergeTreeSinkImpl::commitPart(std::shared_ptr const&, std::shared_ptr&, String const&, unsigned long)::'lambda3'()&&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::commitPart(std::shared_ptr const&, std::shared_ptr&, String const&, unsigned long)::'lambda3'()&&, void DB::ZooKeeperRetriesControl::retryLoop::commitPart(std::shared_ptr const&, std::shared_ptr&, String const&, unsigned long)::'lambda3'()>(DB::ReplicatedMergeTreeSinkImpl::commitPart(std::shared_ptr const&, std::shared_ptr&, String const&, unsigned long)::'lambda3'()&&)::'lambda'()&&) @ 0x000000001660d07f 7. /build/src/Common/ZooKeeper/ZooKeeperRetries.h:52: DB::ReplicatedMergeTreeSinkImpl::commitPart(std::shared_ptr const&, std::shared_ptr&, String const&, unsigned long) @ 0x00000000165fd951 8. /build/src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:492: DB::ReplicatedMergeTreeSinkImpl::finishDelayedChunk(std::shared_ptr const&) @ 0x00000000165f277d 9. /build/src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:437: DB::ReplicatedMergeTreeSinkImpl::consume(DB::Chunk&) @ 0x00000000165fbd00 10. /build/src/Processors/Sinks/SinkToStorage.cpp:10: DB::SinkToStorage::onConsume(DB::Chunk) @ 0x0000000016cee093 11. /build/src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: void std::__function::__policy_invoker::__call_impl[abi:se190107]>(std::__function::__policy_storage const*) @ 0x0000000016c0ad89 12. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000016c0abf5 13. /build/src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: DB::ExceptionKeepingTransform::work() @ 0x0000000016c0a6fe 14. /build/src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x00000000169bd00f 15. /build/src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x00000000169b2105 16. /build/src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeSingleThread(unsigned long) @ 0x00000000169b23be 17. /build/src/Processors/Executors/PipelineExecutor.cpp:416: void std::__function::__policy_invoker::__call_impl[abi:se190107]>(std::__function::__policy_storage const*) @ 0x00000000169b2e3f 18. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc6653 19. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000000fccc4c3 20. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc3d92 21. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fcca080 22. ? @ 0x00007fbc6213eac3 23. ? @ 0x00007fbc621d0850 Job's origin stack trace: 0. /build/src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000000fc33b84 1. /build/src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000000fcc2ea7 2. /build/src/Common/ThreadPool.cpp:401: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fcc7f1c 3. /build/src/Common/ThreadPool.cpp:494: ThreadPoolImpl>::scheduleOrThrowOnError(std::function, Priority) @ 0x000000000fcc7a0e 4. /build/src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::spawnThreadsImpl() @ 0x00000000169b2c0c 5. /build/src/Processors/Executors/PipelineExecutor.cpp:394: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x00000000169b0ba7 6. /build/src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x00000000169b03f4 7. /build/src/Processors/Executors/CompletedPipelineExecutor.cpp:42: void std::__function::__policy_invoker::__call_impl[abi:se190107]::ThreadFromGlobalPoolImpl(DB::CompletedPipelineExecutor::execute()::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169af7e1 8. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc3d92 9. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fcca080 10. ? @ 0x00007fbc6213eac3 11. ? @ 0x00007fbc621d0850 Job's origin stack trace: 0. /build/src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000000fc33b84 1. /build/src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000000fcc2ea7 2. /build/src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fcc535c 3. /build/src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000000fcc584d 4. /build/src/Common/ThreadPool.h:279: DB::CompletedPipelineExecutor::execute() @ 0x00000000169af267 5. /build/src/Server/TCPHandler.cpp:707: DB::TCPHandler::runImpl() @ 0x00000000168e6b2e 6. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 7. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 8. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 9. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 10. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 11. ? @ 0x00007fbc6213eac3 12. ? @ 0x00007fbc621d0850 2025.07.28 11:58:43.969770 [ 17611 ] {0b5b0c88-39d3-4b72-90ed-9f4114d7ec0e} executeQuery: Code: 242. DB::Exception: Table is in readonly mode due to shutdown: replica_path=/clickhouse/tables/01103_optimize_drop_race_zookeeper_test_15/concurrent_optimize_table/replicas/1. (TABLE_IS_READ_ONLY) (version 25.3.6.10636.altinitytest (altinity build)) (from [::1]:51150) (comment: 01103_optimize_drop_race_zookeeper.sh) (query 1, line 1) (in query: INSERT INTO concurrent_optimize_table SELECT rand(1), rand(2), 1 / rand(3), toString(rand(4)), [rand(5), rand(6)], rand(7) % 2 ? NULL : generateUUIDv4(), (rand(8), rand(9)) FROM numbers(10000)), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000a9b78ab 4. /build/src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:866: DB::ReplicatedMergeTreeSinkImpl::commitPart(std::shared_ptr const&, std::shared_ptr&, String const&, unsigned long)::'lambda1'()::operator()() const @ 0x000000001660eed7 5. /build/src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:1124: DB::ReplicatedMergeTreeSinkImpl::commitPart(std::shared_ptr const&, std::shared_ptr&, String const&, unsigned long)::'lambda2'()::operator()() const @ 0x000000001660d1f2 6. /build/src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:1157: void DB::ZooKeeperRetriesControl::retryLoop::commitPart(std::shared_ptr const&, std::shared_ptr&, String const&, unsigned long)::'lambda3'()&, void DB::ZooKeeperRetriesControl::retryLoop::commitPart(std::shared_ptr const&, std::shared_ptr&, String const&, unsigned long)::'lambda3'()>(DB::ReplicatedMergeTreeSinkImpl::commitPart(std::shared_ptr const&, std::shared_ptr&, String const&, unsigned long)::'lambda3'()&&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::commitPart(std::shared_ptr const&, std::shared_ptr&, String const&, unsigned long)::'lambda3'()&&, void DB::ZooKeeperRetriesControl::retryLoop::commitPart(std::shared_ptr const&, std::shared_ptr&, String const&, unsigned long)::'lambda3'()>(DB::ReplicatedMergeTreeSinkImpl::commitPart(std::shared_ptr const&, std::shared_ptr&, String const&, unsigned long)::'lambda3'()&&)::'lambda'()&&) @ 0x000000001660d07f 7. /build/src/Common/ZooKeeper/ZooKeeperRetries.h:52: DB::ReplicatedMergeTreeSinkImpl::commitPart(std::shared_ptr const&, std::shared_ptr&, String const&, unsigned long) @ 0x00000000165fd951 8. /build/src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:492: DB::ReplicatedMergeTreeSinkImpl::finishDelayedChunk(std::shared_ptr const&) @ 0x00000000165f277d 9. /build/src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:437: DB::ReplicatedMergeTreeSinkImpl::consume(DB::Chunk&) @ 0x00000000165fbd00 10. /build/src/Processors/Sinks/SinkToStorage.cpp:10: DB::SinkToStorage::onConsume(DB::Chunk) @ 0x0000000016cee093 11. /build/src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: void std::__function::__policy_invoker::__call_impl[abi:se190107]>(std::__function::__policy_storage const*) @ 0x0000000016c0ad89 12. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000016c0abf5 13. /build/src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: DB::ExceptionKeepingTransform::work() @ 0x0000000016c0a6fe 14. /build/src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x00000000169bd00f 15. /build/src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x00000000169b2105 16. /build/src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeSingleThread(unsigned long) @ 0x00000000169b23be 17. /build/src/Processors/Executors/PipelineExecutor.cpp:416: void std::__function::__policy_invoker::__call_impl[abi:se190107]>(std::__function::__policy_storage const*) @ 0x00000000169b2e3f 18. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc6653 19. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000000fccc4c3 20. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc3d92 21. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fcca080 22. ? @ 0x00007fbc6213eac3 23. ? @ 0x00007fbc621d0850 2025.07.28 11:58:43.983844 [ 17243 ] {b04cf437-a956-4d8f-9c70-214b3798f007} executeQuery: Code: 242. DB::Exception: Table is in readonly mode due to shutdown: replica_path=/clickhouse/tables/01103_optimize_drop_race_zookeeper_test_15/concurrent_optimize_table/replicas/1. (TABLE_IS_READ_ONLY) (version 25.3.6.10636.altinitytest (altinity build)) (from [::1]:51160) (comment: 01103_optimize_drop_race_zookeeper.sh) (query 1, line 1) (in query: INSERT INTO concurrent_optimize_table SELECT rand(1), rand(2), 1 / rand(3), toString(rand(4)), [rand(5), rand(6)], rand(7) % 2 ? NULL : generateUUIDv4(), (rand(8), rand(9)) FROM numbers(10000)), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000a9b78ab 4. /build/src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:866: DB::ReplicatedMergeTreeSinkImpl::commitPart(std::shared_ptr const&, std::shared_ptr&, String const&, unsigned long)::'lambda1'()::operator()() const @ 0x000000001660eed7 5. /build/src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:1124: DB::ReplicatedMergeTreeSinkImpl::commitPart(std::shared_ptr const&, std::shared_ptr&, String const&, unsigned long)::'lambda2'()::operator()() const @ 0x000000001660d1f2 6. /build/src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:1157: void DB::ZooKeeperRetriesControl::retryLoop::commitPart(std::shared_ptr const&, std::shared_ptr&, String const&, unsigned long)::'lambda3'()&, void DB::ZooKeeperRetriesControl::retryLoop::commitPart(std::shared_ptr const&, std::shared_ptr&, String const&, unsigned long)::'lambda3'()>(DB::ReplicatedMergeTreeSinkImpl::commitPart(std::shared_ptr const&, std::shared_ptr&, String const&, unsigned long)::'lambda3'()&&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::commitPart(std::shared_ptr const&, std::shared_ptr&, String const&, unsigned long)::'lambda3'()&&, void DB::ZooKeeperRetriesControl::retryLoop::commitPart(std::shared_ptr const&, std::shared_ptr&, String const&, unsigned long)::'lambda3'()>(DB::ReplicatedMergeTreeSinkImpl::commitPart(std::shared_ptr const&, std::shared_ptr&, String const&, unsigned long)::'lambda3'()&&)::'lambda'()&&) @ 0x000000001660d07f 7. /build/src/Common/ZooKeeper/ZooKeeperRetries.h:52: DB::ReplicatedMergeTreeSinkImpl::commitPart(std::shared_ptr const&, std::shared_ptr&, String const&, unsigned long) @ 0x00000000165fd951 8. /build/src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:492: DB::ReplicatedMergeTreeSinkImpl::finishDelayedChunk(std::shared_ptr const&) @ 0x00000000165f277d 9. /build/src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:437: DB::ReplicatedMergeTreeSinkImpl::consume(DB::Chunk&) @ 0x00000000165fbd00 10. /build/src/Processors/Sinks/SinkToStorage.cpp:10: DB::SinkToStorage::onConsume(DB::Chunk) @ 0x0000000016cee093 11. /build/src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: void std::__function::__policy_invoker::__call_impl[abi:se190107]>(std::__function::__policy_storage const*) @ 0x0000000016c0ad89 12. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000016c0abf5 13. /build/src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: DB::ExceptionKeepingTransform::work() @ 0x0000000016c0a6fe 14. /build/src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x00000000169bd00f 15. /build/src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x00000000169b2105 16. /build/src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeSingleThread(unsigned long) @ 0x00000000169b23be 17. /build/src/Processors/Executors/PipelineExecutor.cpp:416: void std::__function::__policy_invoker::__call_impl[abi:se190107]>(std::__function::__policy_storage const*) @ 0x00000000169b2e3f 18. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc6653 19. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000000fccc4c3 20. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc3d92 21. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fcca080 22. ? @ 0x00007fbc6213eac3 23. ? @ 0x00007fbc621d0850 2025.07.28 11:58:43.993030 [ 17611 ] {} TCPHandler: Code: 242. DB::Exception: Table is in readonly mode due to shutdown: replica_path=/clickhouse/tables/01103_optimize_drop_race_zookeeper_test_15/concurrent_optimize_table/replicas/1. (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000a9b78ab 4. /build/src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:866: DB::ReplicatedMergeTreeSinkImpl::commitPart(std::shared_ptr const&, std::shared_ptr&, String const&, unsigned long)::'lambda1'()::operator()() const @ 0x000000001660eed7 5. /build/src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:1124: DB::ReplicatedMergeTreeSinkImpl::commitPart(std::shared_ptr const&, std::shared_ptr&, String const&, unsigned long)::'lambda2'()::operator()() const @ 0x000000001660d1f2 6. /build/src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:1157: void DB::ZooKeeperRetriesControl::retryLoop::commitPart(std::shared_ptr const&, std::shared_ptr&, String const&, unsigned long)::'lambda3'()&, void DB::ZooKeeperRetriesControl::retryLoop::commitPart(std::shared_ptr const&, std::shared_ptr&, String const&, unsigned long)::'lambda3'()>(DB::ReplicatedMergeTreeSinkImpl::commitPart(std::shared_ptr const&, std::shared_ptr&, String const&, unsigned long)::'lambda3'()&&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::commitPart(std::shared_ptr const&, std::shared_ptr&, String const&, unsigned long)::'lambda3'()&&, void DB::ZooKeeperRetriesControl::retryLoop::commitPart(std::shared_ptr const&, std::shared_ptr&, String const&, unsigned long)::'lambda3'()>(DB::ReplicatedMergeTreeSinkImpl::commitPart(std::shared_ptr const&, std::shared_ptr&, String const&, unsigned long)::'lambda3'()&&)::'lambda'()&&) @ 0x000000001660d07f 7. /build/src/Common/ZooKeeper/ZooKeeperRetries.h:52: DB::ReplicatedMergeTreeSinkImpl::commitPart(std::shared_ptr const&, std::shared_ptr&, String const&, unsigned long) @ 0x00000000165fd951 8. /build/src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:492: DB::ReplicatedMergeTreeSinkImpl::finishDelayedChunk(std::shared_ptr const&) @ 0x00000000165f277d 9. /build/src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:437: DB::ReplicatedMergeTreeSinkImpl::consume(DB::Chunk&) @ 0x00000000165fbd00 10. /build/src/Processors/Sinks/SinkToStorage.cpp:10: DB::SinkToStorage::onConsume(DB::Chunk) @ 0x0000000016cee093 11. /build/src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: void std::__function::__policy_invoker::__call_impl[abi:se190107]>(std::__function::__policy_storage const*) @ 0x0000000016c0ad89 12. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000016c0abf5 13. /build/src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: DB::ExceptionKeepingTransform::work() @ 0x0000000016c0a6fe 14. /build/src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x00000000169bd00f 15. /build/src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x00000000169b2105 16. /build/src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeSingleThread(unsigned long) @ 0x00000000169b23be 17. /build/src/Processors/Executors/PipelineExecutor.cpp:416: void std::__function::__policy_invoker::__call_impl[abi:se190107]>(std::__function::__policy_storage const*) @ 0x00000000169b2e3f 18. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc6653 19. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000000fccc4c3 20. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc3d92 21. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fcca080 22. ? @ 0x00007fbc6213eac3 23. ? @ 0x00007fbc621d0850 Job's origin stack trace: 0. /build/src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000000fc33b84 1. /build/src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000000fcc2ea7 2. /build/src/Common/ThreadPool.cpp:401: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fcc7f1c 3. /build/src/Common/ThreadPool.cpp:494: ThreadPoolImpl>::scheduleOrThrowOnError(std::function, Priority) @ 0x000000000fcc7a0e 4. /build/src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::spawnThreadsImpl() @ 0x00000000169b2c0c 5. /build/src/Processors/Executors/PipelineExecutor.cpp:394: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x00000000169b0ba7 6. /build/src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x00000000169b03f4 7. /build/src/Processors/Executors/CompletedPipelineExecutor.cpp:42: void std::__function::__policy_invoker::__call_impl[abi:se190107]::ThreadFromGlobalPoolImpl(DB::CompletedPipelineExecutor::execute()::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169af7e1 8. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc3d92 9. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fcca080 10. ? @ 0x00007fbc6213eac3 11. ? @ 0x00007fbc621d0850 Job's origin stack trace: 0. /build/src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000000fc33b84 1. /build/src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000000fcc2ea7 2. /build/src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fcc535c 3. /build/src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000000fcc584d 4. /build/src/Common/ThreadPool.h:279: DB::CompletedPipelineExecutor::execute() @ 0x00000000169af267 5. /build/src/Server/TCPHandler.cpp:707: DB::TCPHandler::runImpl() @ 0x00000000168e6b2e 6. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 7. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 8. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 9. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 10. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 11. ? @ 0x00007fbc6213eac3 12. ? @ 0x00007fbc621d0850 2025.07.28 11:58:44.031068 [ 17243 ] {} TCPHandler: Code: 242. DB::Exception: Table is in readonly mode due to shutdown: replica_path=/clickhouse/tables/01103_optimize_drop_race_zookeeper_test_15/concurrent_optimize_table/replicas/1. (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000a9b78ab 4. /build/src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:866: DB::ReplicatedMergeTreeSinkImpl::commitPart(std::shared_ptr const&, std::shared_ptr&, String const&, unsigned long)::'lambda1'()::operator()() const @ 0x000000001660eed7 5. /build/src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:1124: DB::ReplicatedMergeTreeSinkImpl::commitPart(std::shared_ptr const&, std::shared_ptr&, String const&, unsigned long)::'lambda2'()::operator()() const @ 0x000000001660d1f2 6. /build/src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:1157: void DB::ZooKeeperRetriesControl::retryLoop::commitPart(std::shared_ptr const&, std::shared_ptr&, String const&, unsigned long)::'lambda3'()&, void DB::ZooKeeperRetriesControl::retryLoop::commitPart(std::shared_ptr const&, std::shared_ptr&, String const&, unsigned long)::'lambda3'()>(DB::ReplicatedMergeTreeSinkImpl::commitPart(std::shared_ptr const&, std::shared_ptr&, String const&, unsigned long)::'lambda3'()&&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::commitPart(std::shared_ptr const&, std::shared_ptr&, String const&, unsigned long)::'lambda3'()&&, void DB::ZooKeeperRetriesControl::retryLoop::commitPart(std::shared_ptr const&, std::shared_ptr&, String const&, unsigned long)::'lambda3'()>(DB::ReplicatedMergeTreeSinkImpl::commitPart(std::shared_ptr const&, std::shared_ptr&, String const&, unsigned long)::'lambda3'()&&)::'lambda'()&&) @ 0x000000001660d07f 7. /build/src/Common/ZooKeeper/ZooKeeperRetries.h:52: DB::ReplicatedMergeTreeSinkImpl::commitPart(std::shared_ptr const&, std::shared_ptr&, String const&, unsigned long) @ 0x00000000165fd951 8. /build/src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:492: DB::ReplicatedMergeTreeSinkImpl::finishDelayedChunk(std::shared_ptr const&) @ 0x00000000165f277d 9. /build/src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:437: DB::ReplicatedMergeTreeSinkImpl::consume(DB::Chunk&) @ 0x00000000165fbd00 10. /build/src/Processors/Sinks/SinkToStorage.cpp:10: DB::SinkToStorage::onConsume(DB::Chunk) @ 0x0000000016cee093 11. /build/src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: void std::__function::__policy_invoker::__call_impl[abi:se190107]>(std::__function::__policy_storage const*) @ 0x0000000016c0ad89 12. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000016c0abf5 13. /build/src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: DB::ExceptionKeepingTransform::work() @ 0x0000000016c0a6fe 14. /build/src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x00000000169bd00f 15. /build/src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x00000000169b2105 16. /build/src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeSingleThread(unsigned long) @ 0x00000000169b23be 17. /build/src/Processors/Executors/PipelineExecutor.cpp:416: void std::__function::__policy_invoker::__call_impl[abi:se190107]>(std::__function::__policy_storage const*) @ 0x00000000169b2e3f 18. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc6653 19. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000000fccc4c3 20. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc3d92 21. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fcca080 22. ? @ 0x00007fbc6213eac3 23. ? @ 0x00007fbc621d0850 Job's origin stack trace: 0. /build/src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000000fc33b84 1. /build/src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000000fcc2ea7 2. /build/src/Common/ThreadPool.cpp:401: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fcc7f1c 3. /build/src/Common/ThreadPool.cpp:494: ThreadPoolImpl>::scheduleOrThrowOnError(std::function, Priority) @ 0x000000000fcc7a0e 4. /build/src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::spawnThreadsImpl() @ 0x00000000169b2c0c 5. /build/src/Processors/Executors/PipelineExecutor.cpp:394: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x00000000169b0ba7 6. /build/src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x00000000169b03f4 7. /build/src/Processors/Executors/CompletedPipelineExecutor.cpp:42: void std::__function::__policy_invoker::__call_impl[abi:se190107]::ThreadFromGlobalPoolImpl(DB::CompletedPipelineExecutor::execute()::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169af7e1 8. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc3d92 9. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fcca080 10. ? @ 0x00007fbc6213eac3 11. ? @ 0x00007fbc621d0850 Job's origin stack trace: 0. /build/src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000000fc33b84 1. /build/src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000000fcc2ea7 2. /build/src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fcc535c 3. /build/src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000000fcc584d 4. /build/src/Common/ThreadPool.h:279: DB::CompletedPipelineExecutor::execute() @ 0x00000000169af267 5. /build/src/Server/TCPHandler.cpp:707: DB::TCPHandler::runImpl() @ 0x00000000168e6b2e 6. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 7. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 8. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 9. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 10. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 11. ? @ 0x00007fbc6213eac3 12. ? @ 0x00007fbc621d0850 2025.07.28 11:58:44.076750 [ 5747 ] {25a96426-8b72-46d3-8cca-034ff621dac7} executeQuery: Code: 60. DB::Exception: Table test_15.concurrent_optimize_table does not exist. (UNKNOWN_TABLE) (version 25.3.6.10636.altinitytest (altinity build)) (from [::1]:51274) (comment: 01103_optimize_drop_race_zookeeper.sh) (query 1, line 1) (in query: OPTIMIZE TABLE concurrent_optimize_table FINAL), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000a06a8eb 4. /build/src/Databases/IDatabase.cpp:41: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x0000000013dd565f 5. /build/src/Interpreters/DatabaseCatalog.cpp:442: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x00000000144f0869 6. /build/src/Interpreters/DatabaseCatalog.cpp:976: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x00000000144f6c88 7. /build/src/Interpreters/InterpreterOptimizeQuery.cpp:40: DB::InterpreterOptimizeQuery::execute() @ 0x0000000014cd71de 8. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88dc9 9. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 10. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 11. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 12. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 13. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 14. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 15. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 16. ? @ 0x00007fbc6213eac3 17. ? @ 0x00007fbc621d0850 2025.07.28 11:58:44.087848 [ 5747 ] {} TCPHandler: Code: 60. DB::Exception: Table test_15.concurrent_optimize_table does not exist. (UNKNOWN_TABLE), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000a06a8eb 4. /build/src/Databases/IDatabase.cpp:41: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x0000000013dd565f 5. /build/src/Interpreters/DatabaseCatalog.cpp:442: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x00000000144f0869 6. /build/src/Interpreters/DatabaseCatalog.cpp:976: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x00000000144f6c88 7. /build/src/Interpreters/InterpreterOptimizeQuery.cpp:40: DB::InterpreterOptimizeQuery::execute() @ 0x0000000014cd71de 8. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88dc9 9. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 10. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 11. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 12. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 13. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 14. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 15. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 16. ? @ 0x00007fbc6213eac3 17. ? @ 0x00007fbc621d0850 2025.07.28 11:58:44.113315 [ 17203 ] {f81d1ce9-6424-4c86-bcfc-457944753b41} executeQuery: Code: 60. DB::Exception: Table test_15.concurrent_optimize_table does not exist. (UNKNOWN_TABLE) (version 25.3.6.10636.altinitytest (altinity build)) (from [::1]:51298) (comment: 01103_optimize_drop_race_zookeeper.sh) (query 1, line 1) (in query: INSERT INTO concurrent_optimize_table SELECT rand(1), rand(2), 1 / rand(3), toString(rand(4)), [rand(5), rand(6)], rand(7) % 2 ? NULL : generateUUIDv4(), (rand(8), rand(9)) FROM numbers(10000)), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000a06a8eb 4. /build/src/Databases/IDatabase.cpp:41: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x0000000013dd565f 5. /build/src/Interpreters/DatabaseCatalog.cpp:442: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x00000000144f0869 6. /build/src/Interpreters/DatabaseCatalog.cpp:976: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x00000000144f6c88 7. /build/src/Interpreters/InterpreterInsertQuery.cpp:169: DB::InterpreterInsertQuery::getTable(DB::ASTInsertQuery&) @ 0x000000001492bf04 8. /build/src/Interpreters/InterpreterInsertQuery.cpp:829: DB::InterpreterInsertQuery::execute() @ 0x0000000014933938 9. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88dc9 10. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 11. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 12. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 13. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 14. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 16. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 17. ? @ 0x00007fbc6213eac3 18. ? @ 0x00007fbc621d0850 2025.07.28 11:58:44.124849 [ 17203 ] {} TCPHandler: Code: 60. DB::Exception: Table test_15.concurrent_optimize_table does not exist. (UNKNOWN_TABLE), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000a06a8eb 4. /build/src/Databases/IDatabase.cpp:41: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x0000000013dd565f 5. /build/src/Interpreters/DatabaseCatalog.cpp:442: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x00000000144f0869 6. /build/src/Interpreters/DatabaseCatalog.cpp:976: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x00000000144f6c88 7. /build/src/Interpreters/InterpreterInsertQuery.cpp:169: DB::InterpreterInsertQuery::getTable(DB::ASTInsertQuery&) @ 0x000000001492bf04 8. /build/src/Interpreters/InterpreterInsertQuery.cpp:829: DB::InterpreterInsertQuery::execute() @ 0x0000000014933938 9. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88dc9 10. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 11. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 12. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 13. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 14. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 16. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 17. ? @ 0x00007fbc6213eac3 18. ? @ 0x00007fbc621d0850 2025.07.28 11:58:44.204129 [ 17255 ] {8c0eb9c5-3098-4092-806b-202d1478d1a0} executeQuery: Code: 60. DB::Exception: Table test_15.concurrent_optimize_table does not exist. (UNKNOWN_TABLE) (version 25.3.6.10636.altinitytest (altinity build)) (from [::1]:51300) (comment: 01103_optimize_drop_race_zookeeper.sh) (query 1, line 1) (in query: INSERT INTO concurrent_optimize_table SELECT rand(1), rand(2), 1 / rand(3), toString(rand(4)), [rand(5), rand(6)], rand(7) % 2 ? NULL : generateUUIDv4(), (rand(8), rand(9)) FROM numbers(10000)), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000a06a8eb 4. /build/src/Databases/IDatabase.cpp:41: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x0000000013dd565f 5. /build/src/Interpreters/DatabaseCatalog.cpp:442: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x00000000144f0869 6. /build/src/Interpreters/DatabaseCatalog.cpp:976: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x00000000144f6c88 7. /build/src/Interpreters/InterpreterInsertQuery.cpp:169: DB::InterpreterInsertQuery::getTable(DB::ASTInsertQuery&) @ 0x000000001492bf04 8. /build/src/Interpreters/InterpreterInsertQuery.cpp:829: DB::InterpreterInsertQuery::execute() @ 0x0000000014933938 9. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88dc9 10. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 11. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 12. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 13. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 14. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 16. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 17. ? @ 0x00007fbc6213eac3 18. ? @ 0x00007fbc621d0850 2025.07.28 11:58:44.230795 [ 17255 ] {} TCPHandler: Code: 60. DB::Exception: Table test_15.concurrent_optimize_table does not exist. (UNKNOWN_TABLE), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000a06a8eb 4. /build/src/Databases/IDatabase.cpp:41: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x0000000013dd565f 5. /build/src/Interpreters/DatabaseCatalog.cpp:442: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x00000000144f0869 6. /build/src/Interpreters/DatabaseCatalog.cpp:976: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x00000000144f6c88 7. /build/src/Interpreters/InterpreterInsertQuery.cpp:169: DB::InterpreterInsertQuery::getTable(DB::ASTInsertQuery&) @ 0x000000001492bf04 8. /build/src/Interpreters/InterpreterInsertQuery.cpp:829: DB::InterpreterInsertQuery::execute() @ 0x0000000014933938 9. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88dc9 10. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 11. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 12. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 13. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 14. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 16. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 17. ? @ 0x00007fbc6213eac3 18. ? @ 0x00007fbc621d0850 2025.07.28 11:58:44.235684 [ 3285 ] {7867c98d-2e75-48d2-9511-d453c901bf62} executeQuery: Code: 60. DB::Exception: Table test_15.concurrent_optimize_table does not exist. (UNKNOWN_TABLE) (version 25.3.6.10636.altinitytest (altinity build)) (from [::1]:51316) (comment: 01103_optimize_drop_race_zookeeper.sh) (query 1, line 1) (in query: INSERT INTO concurrent_optimize_table SELECT rand(1), rand(2), 1 / rand(3), toString(rand(4)), [rand(5), rand(6)], rand(7) % 2 ? NULL : generateUUIDv4(), (rand(8), rand(9)) FROM numbers(10000)), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000a06a8eb 4. /build/src/Databases/IDatabase.cpp:41: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x0000000013dd565f 5. /build/src/Interpreters/DatabaseCatalog.cpp:442: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x00000000144f0869 6. /build/src/Interpreters/DatabaseCatalog.cpp:976: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x00000000144f6c88 7. /build/src/Interpreters/InterpreterInsertQuery.cpp:169: DB::InterpreterInsertQuery::getTable(DB::ASTInsertQuery&) @ 0x000000001492bf04 8. /build/src/Interpreters/InterpreterInsertQuery.cpp:829: DB::InterpreterInsertQuery::execute() @ 0x0000000014933938 9. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88dc9 10. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 11. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 12. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 13. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 14. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 16. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 17. ? @ 0x00007fbc6213eac3 18. ? @ 0x00007fbc621d0850 2025.07.28 11:58:44.272632 [ 3285 ] {} TCPHandler: Code: 60. DB::Exception: Table test_15.concurrent_optimize_table does not exist. (UNKNOWN_TABLE), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000a06a8eb 4. /build/src/Databases/IDatabase.cpp:41: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x0000000013dd565f 5. /build/src/Interpreters/DatabaseCatalog.cpp:442: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x00000000144f0869 6. /build/src/Interpreters/DatabaseCatalog.cpp:976: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x00000000144f6c88 7. /build/src/Interpreters/InterpreterInsertQuery.cpp:169: DB::InterpreterInsertQuery::getTable(DB::ASTInsertQuery&) @ 0x000000001492bf04 8. /build/src/Interpreters/InterpreterInsertQuery.cpp:829: DB::InterpreterInsertQuery::execute() @ 0x0000000014933938 9. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88dc9 10. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 11. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 12. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 13. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 14. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 16. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 17. ? @ 0x00007fbc6213eac3 18. ? @ 0x00007fbc621d0850 2025.07.28 11:58:44.284679 [ 5747 ] {6a6875de-0b30-4fa7-853f-e03aa53aad41} executeQuery: Code: 60. DB::Exception: Table test_15.concurrent_optimize_table does not exist. (UNKNOWN_TABLE) (version 25.3.6.10636.altinitytest (altinity build)) (from [::1]:51332) (comment: 01103_optimize_drop_race_zookeeper.sh) (query 1, line 1) (in query: INSERT INTO concurrent_optimize_table SELECT rand(1), rand(2), 1 / rand(3), toString(rand(4)), [rand(5), rand(6)], rand(7) % 2 ? NULL : generateUUIDv4(), (rand(8), rand(9)) FROM numbers(10000)), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000a06a8eb 4. /build/src/Databases/IDatabase.cpp:41: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x0000000013dd565f 5. /build/src/Interpreters/DatabaseCatalog.cpp:442: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x00000000144f0869 6. /build/src/Interpreters/DatabaseCatalog.cpp:976: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x00000000144f6c88 7. /build/src/Interpreters/InterpreterInsertQuery.cpp:169: DB::InterpreterInsertQuery::getTable(DB::ASTInsertQuery&) @ 0x000000001492bf04 8. /build/src/Interpreters/InterpreterInsertQuery.cpp:829: DB::InterpreterInsertQuery::execute() @ 0x0000000014933938 9. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88dc9 10. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 11. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 12. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 13. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 14. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 16. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 17. ? @ 0x00007fbc6213eac3 18. ? @ 0x00007fbc621d0850 2025.07.28 11:58:44.295165 [ 5747 ] {} TCPHandler: Code: 60. DB::Exception: Table test_15.concurrent_optimize_table does not exist. (UNKNOWN_TABLE), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000a06a8eb 4. /build/src/Databases/IDatabase.cpp:41: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x0000000013dd565f 5. /build/src/Interpreters/DatabaseCatalog.cpp:442: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x00000000144f0869 6. /build/src/Interpreters/DatabaseCatalog.cpp:976: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x00000000144f6c88 7. /build/src/Interpreters/InterpreterInsertQuery.cpp:169: DB::InterpreterInsertQuery::getTable(DB::ASTInsertQuery&) @ 0x000000001492bf04 8. /build/src/Interpreters/InterpreterInsertQuery.cpp:829: DB::InterpreterInsertQuery::execute() @ 0x0000000014933938 9. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88dc9 10. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 11. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 12. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 13. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 14. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 16. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 17. ? @ 0x00007fbc6213eac3 18. ? @ 0x00007fbc621d0850 2025.07.28 11:58:44.338571 [ 33889 ] {} test_15.concurrent_optimize_table (7cfe5735-8263-4fcf-9734-2870fd1a3f46): Another replica was suddenly created, will keep the table /clickhouse/tables/01103_optimize_drop_race_zookeeper_test_15/concurrent_optimize_table/replicas/1 2025.07.28 11:58:44.341311 [ 17287 ] {507befbd-285c-4502-bc4f-cfa85642abca} executeQuery: Code: 60. DB::Exception: Table test_15.concurrent_optimize_table does not exist. (UNKNOWN_TABLE) (version 25.3.6.10636.altinitytest (altinity build)) (from [::1]:51348) (comment: 01103_optimize_drop_race_zookeeper.sh) (query 1, line 1) (in query: OPTIMIZE TABLE concurrent_optimize_table FINAL), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000a06a8eb 4. /build/src/Databases/IDatabase.cpp:41: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x0000000013dd565f 5. /build/src/Interpreters/DatabaseCatalog.cpp:442: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x00000000144f0869 6. /build/src/Interpreters/DatabaseCatalog.cpp:976: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x00000000144f6c88 7. /build/src/Interpreters/InterpreterOptimizeQuery.cpp:40: DB::InterpreterOptimizeQuery::execute() @ 0x0000000014cd71de 8. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88dc9 9. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 10. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 11. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 12. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 13. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 14. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 15. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 16. ? @ 0x00007fbc6213eac3 17. ? @ 0x00007fbc621d0850 2025.07.28 11:58:44.342625 [ 17255 ] {42df2008-0195-4c27-bea3-aab36d520fad} executeQuery: Code: 60. DB::Exception: Table test_15.concurrent_optimize_table does not exist. (UNKNOWN_TABLE) (version 25.3.6.10636.altinitytest (altinity build)) (from [::1]:51358) (comment: 01103_optimize_drop_race_zookeeper.sh) (query 1, line 1) (in query: INSERT INTO concurrent_optimize_table SELECT rand(1), rand(2), 1 / rand(3), toString(rand(4)), [rand(5), rand(6)], rand(7) % 2 ? NULL : generateUUIDv4(), (rand(8), rand(9)) FROM numbers(10000)), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000a06a8eb 4. /build/src/Databases/IDatabase.cpp:41: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x0000000013dd565f 5. /build/src/Interpreters/DatabaseCatalog.cpp:442: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x00000000144f0869 6. /build/src/Interpreters/DatabaseCatalog.cpp:976: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x00000000144f6c88 7. /build/src/Interpreters/InterpreterInsertQuery.cpp:169: DB::InterpreterInsertQuery::getTable(DB::ASTInsertQuery&) @ 0x000000001492bf04 8. /build/src/Interpreters/InterpreterInsertQuery.cpp:829: DB::InterpreterInsertQuery::execute() @ 0x0000000014933938 9. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88dc9 10. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 11. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 12. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 13. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 14. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 16. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 17. ? @ 0x00007fbc6213eac3 18. ? @ 0x00007fbc621d0850 2025.07.28 11:58:44.355545 [ 17287 ] {} TCPHandler: Code: 60. DB::Exception: Table test_15.concurrent_optimize_table does not exist. (UNKNOWN_TABLE), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000a06a8eb 4. /build/src/Databases/IDatabase.cpp:41: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x0000000013dd565f 5. /build/src/Interpreters/DatabaseCatalog.cpp:442: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x00000000144f0869 6. /build/src/Interpreters/DatabaseCatalog.cpp:976: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x00000000144f6c88 7. /build/src/Interpreters/InterpreterOptimizeQuery.cpp:40: DB::InterpreterOptimizeQuery::execute() @ 0x0000000014cd71de 8. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88dc9 9. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 10. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 11. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 12. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 13. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 14. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 15. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 16. ? @ 0x00007fbc6213eac3 17. ? @ 0x00007fbc621d0850 2025.07.28 11:58:44.378641 [ 17255 ] {} TCPHandler: Code: 60. DB::Exception: Table test_15.concurrent_optimize_table does not exist. (UNKNOWN_TABLE), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000a06a8eb 4. /build/src/Databases/IDatabase.cpp:41: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x0000000013dd565f 5. /build/src/Interpreters/DatabaseCatalog.cpp:442: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x00000000144f0869 6. /build/src/Interpreters/DatabaseCatalog.cpp:976: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x00000000144f6c88 7. /build/src/Interpreters/InterpreterInsertQuery.cpp:169: DB::InterpreterInsertQuery::getTable(DB::ASTInsertQuery&) @ 0x000000001492bf04 8. /build/src/Interpreters/InterpreterInsertQuery.cpp:829: DB::InterpreterInsertQuery::execute() @ 0x0000000014933938 9. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88dc9 10. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 11. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 12. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 13. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 14. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 16. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 17. ? @ 0x00007fbc6213eac3 18. ? @ 0x00007fbc621d0850 2025.07.28 11:58:44.493277 [ 4963 ] {49b8ebc6-1fb5-4791-b95e-6d0b5b270ff2} executeQuery: Code: 60. DB::Exception: Table test_15.concurrent_optimize_table does not exist. (UNKNOWN_TABLE) (version 25.3.6.10636.altinitytest (altinity build)) (from [::1]:51372) (comment: 01103_optimize_drop_race_zookeeper.sh) (query 1, line 1) (in query: OPTIMIZE TABLE concurrent_optimize_table FINAL), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000a06a8eb 4. /build/src/Databases/IDatabase.cpp:41: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x0000000013dd565f 5. /build/src/Interpreters/DatabaseCatalog.cpp:442: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x00000000144f0869 6. /build/src/Interpreters/DatabaseCatalog.cpp:976: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x00000000144f6c88 7. /build/src/Interpreters/InterpreterOptimizeQuery.cpp:40: DB::InterpreterOptimizeQuery::execute() @ 0x0000000014cd71de 8. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88dc9 9. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 10. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 11. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 12. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 13. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 14. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 15. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 16. ? @ 0x00007fbc6213eac3 17. ? @ 0x00007fbc621d0850 2025.07.28 11:58:44.504289 [ 4963 ] {} TCPHandler: Code: 60. DB::Exception: Table test_15.concurrent_optimize_table does not exist. (UNKNOWN_TABLE), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000a06a8eb 4. /build/src/Databases/IDatabase.cpp:41: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x0000000013dd565f 5. /build/src/Interpreters/DatabaseCatalog.cpp:442: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x00000000144f0869 6. /build/src/Interpreters/DatabaseCatalog.cpp:976: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x00000000144f6c88 7. /build/src/Interpreters/InterpreterOptimizeQuery.cpp:40: DB::InterpreterOptimizeQuery::execute() @ 0x0000000014cd71de 8. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88dc9 9. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 10. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 11. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 12. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 13. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 14. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 15. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 16. ? @ 0x00007fbc6213eac3 17. ? @ 0x00007fbc621d0850 2025.07.28 11:58:44.567472 [ 11826 ] {3553e6a6-354f-435c-b3df-07a0140a423e} executeQuery: Code: 60. DB::Exception: Table test_15.concurrent_optimize_table does not exist. (UNKNOWN_TABLE) (version 25.3.6.10636.altinitytest (altinity build)) (from [::1]:51402) (comment: 01103_optimize_drop_race_zookeeper.sh) (query 1, line 1) (in query: INSERT INTO concurrent_optimize_table SELECT rand(1), rand(2), 1 / rand(3), toString(rand(4)), [rand(5), rand(6)], rand(7) % 2 ? NULL : generateUUIDv4(), (rand(8), rand(9)) FROM numbers(10000)), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000a06a8eb 4. /build/src/Databases/IDatabase.cpp:41: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x0000000013dd565f 5. /build/src/Interpreters/DatabaseCatalog.cpp:442: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x00000000144f0869 6. /build/src/Interpreters/DatabaseCatalog.cpp:976: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x00000000144f6c88 7. /build/src/Interpreters/InterpreterInsertQuery.cpp:169: DB::InterpreterInsertQuery::getTable(DB::ASTInsertQuery&) @ 0x000000001492bf04 8. /build/src/Interpreters/InterpreterInsertQuery.cpp:829: DB::InterpreterInsertQuery::execute() @ 0x0000000014933938 9. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88dc9 10. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 11. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 12. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 13. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 14. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 16. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 17. ? @ 0x00007fbc6213eac3 18. ? @ 0x00007fbc621d0850 2025.07.28 11:58:44.586237 [ 11826 ] {} TCPHandler: Code: 60. DB::Exception: Table test_15.concurrent_optimize_table does not exist. (UNKNOWN_TABLE), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000a06a8eb 4. /build/src/Databases/IDatabase.cpp:41: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x0000000013dd565f 5. /build/src/Interpreters/DatabaseCatalog.cpp:442: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x00000000144f0869 6. /build/src/Interpreters/DatabaseCatalog.cpp:976: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x00000000144f6c88 7. /build/src/Interpreters/InterpreterInsertQuery.cpp:169: DB::InterpreterInsertQuery::getTable(DB::ASTInsertQuery&) @ 0x000000001492bf04 8. /build/src/Interpreters/InterpreterInsertQuery.cpp:829: DB::InterpreterInsertQuery::execute() @ 0x0000000014933938 9. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88dc9 10. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 11. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 12. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 13. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 14. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 16. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 17. ? @ 0x00007fbc6213eac3 18. ? @ 0x00007fbc621d0850 2025.07.28 11:58:44.625869 [ 4581 ] {3a042505-6f50-4055-b1a0-7b88531eba21} executeQuery: Code: 60. DB::Exception: Table test_15.concurrent_optimize_table does not exist. (UNKNOWN_TABLE) (version 25.3.6.10636.altinitytest (altinity build)) (from [::1]:51422) (comment: 01103_optimize_drop_race_zookeeper.sh) (query 1, line 1) (in query: OPTIMIZE TABLE concurrent_optimize_table FINAL), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000a06a8eb 4. /build/src/Databases/IDatabase.cpp:41: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x0000000013dd565f 5. /build/src/Interpreters/DatabaseCatalog.cpp:442: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x00000000144f0869 6. /build/src/Interpreters/DatabaseCatalog.cpp:976: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x00000000144f6c88 7. /build/src/Interpreters/InterpreterOptimizeQuery.cpp:40: DB::InterpreterOptimizeQuery::execute() @ 0x0000000014cd71de 8. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88dc9 9. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 10. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 11. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 12. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 13. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 14. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 15. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 16. ? @ 0x00007fbc6213eac3 17. ? @ 0x00007fbc621d0850 2025.07.28 11:58:44.640226 [ 4581 ] {} TCPHandler: Code: 60. DB::Exception: Table test_15.concurrent_optimize_table does not exist. (UNKNOWN_TABLE), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000a06a8eb 4. /build/src/Databases/IDatabase.cpp:41: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x0000000013dd565f 5. /build/src/Interpreters/DatabaseCatalog.cpp:442: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x00000000144f0869 6. /build/src/Interpreters/DatabaseCatalog.cpp:976: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x00000000144f6c88 7. /build/src/Interpreters/InterpreterOptimizeQuery.cpp:40: DB::InterpreterOptimizeQuery::execute() @ 0x0000000014cd71de 8. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88dc9 9. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 10. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 11. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 12. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 13. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 14. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 15. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 16. ? @ 0x00007fbc6213eac3 17. ? @ 0x00007fbc621d0850 2025.07.28 11:58:44.658978 [ 3970 ] {} test_13.rmt2 (7f9b740d-015c-470e-8cc6-8ba33be0dc63): auto DB::StorageReplicatedMergeTree::processQueueEntry(ReplicatedMergeTreeQueue::SelectedEntryPtr)::(anonymous class)::operator()(LogEntryPtr &) const: Code: 86. DB::HTTPException: Received error from remote server http://146b4357c08d:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Ftest%2F01165%2Ftest_13%2Frmt%2Freplicas%2F1&part=20250728_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.6.10636.altinitytest (altinity build)) '. (RECEIVED_ERROR_FROM_REMOTE_IO_SERVER), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.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 const&, int&&, String const&, unsigned long&&, String const&) @ 0x000000000feda8d9 4. /build/src/IO/HTTPCommon.cpp:104: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x000000000feda6e2 5. /build/src/IO/HTTPCommon.cpp:93: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x000000000feda537 6. /build/src/IO/ReadWriteBufferFromHTTP.cpp:277: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x000000001184a4c4 7. /build/src/IO/ReadWriteBufferFromHTTP.cpp:285: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x000000001184a615 8. /build/src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x000000001184ae59 9. /build/src/IO/ReadWriteBufferFromHTTP.cpp:472: void std::__function::__policy_invoker::__call_impl[abi:se190107]>(std::__function::__policy_storage const*) @ 0x000000001184cedd 10. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001184858b 11. /build/src/IO/ReadWriteBufferFromHTTP.cpp:465: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x000000001184bf0b 12. /build/src/IO/ReadBuffer.h:60: DB::ReadBuffer::next() @ 0x000000000a148c7b 13. /build/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) @ 0x0000000011849fb2 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]>&)>&, 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&) @ 0x0000000011841980 15. /build/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) @ 0x000000001621208e 16. /build/src/Storages/StorageReplicatedMergeTree.cpp:5228: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl[abi:se190107] const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000015f9a5fe 17. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000015ed8bfd 18. /build/src/Storages/StorageReplicatedMergeTree.cpp:2514: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x0000000015ec9aab 19. /build/src/Storages/StorageReplicatedMergeTree.cpp:2349: DB::StorageReplicatedMergeTree::executeLogEntry(DB::ReplicatedMergeTreeLogEntry&) @ 0x0000000015eba91b 20. /build/src/Storages/StorageReplicatedMergeTree.cpp:3876: bool std::__function::__policy_invoker&)>::__call_impl[abi:se190107])::$_1, bool (std::shared_ptr&)>>(std::__function::__policy_storage const*, std::shared_ptr&) @ 0x0000000015f9837e 21. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000165d6fc3 22. /build/src/Storages/StorageReplicatedMergeTree.cpp:3872: DB::StorageReplicatedMergeTree::processQueueEntry(std::shared_ptr) @ 0x0000000015efc18a 23. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001624c1b2 24. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000162f9c70 25. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x00000000162fa55a 26. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc6653 27. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000000fccc4c3 28. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc3d92 29. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fcca080 30. ? @ 0x00007fbc6213eac3 31. ? @ 0x00007fbc621d0850 (version 25.3.6.10636.altinitytest (altinity build)) 2025.07.28 11:58:44.768320 [ 4446 ] {3426f74b-9ea6-4bcd-86bc-8bcdf3e3c172} executeQuery: Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01103_optimize_drop_race_zookeeper_test_15/concurrent_optimize_table/replicas/1). (TABLE_IS_READ_ONLY) (version 25.3.6.10636.altinitytest (altinity build)) (from [::1]:51456) (comment: 01103_optimize_drop_race_zookeeper.sh) (query 1, line 1) (in query: OPTIMIZE TABLE concurrent_optimize_table FINAL), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000a9b78ab 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:5935: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000015e86144 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:6112: DB::StorageReplicatedMergeTree::optimize(std::shared_ptr const&, std::shared_ptr const&, std::shared_ptr const&, bool, bool, std::vector> const&, bool, std::shared_ptr) @ 0x0000000015f21f2c 6. /build/src/Interpreters/InterpreterOptimizeQuery.cpp:84: DB::InterpreterOptimizeQuery::execute() @ 0x0000000014cd782e 7. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88dc9 8. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 9. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 10. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 11. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 12. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 13. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 14. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 15. ? @ 0x00007fbc6213eac3 16. ? @ 0x00007fbc621d0850 2025.07.28 11:58:44.783177 [ 4446 ] {} TCPHandler: Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01103_optimize_drop_race_zookeeper_test_15/concurrent_optimize_table/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000a9b78ab 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:5935: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000015e86144 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:6112: DB::StorageReplicatedMergeTree::optimize(std::shared_ptr const&, std::shared_ptr const&, std::shared_ptr const&, bool, bool, std::vector> const&, bool, std::shared_ptr) @ 0x0000000015f21f2c 6. /build/src/Interpreters/InterpreterOptimizeQuery.cpp:84: DB::InterpreterOptimizeQuery::execute() @ 0x0000000014cd782e 7. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88dc9 8. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 9. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 10. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 11. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 12. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 13. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 14. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 15. ? @ 0x00007fbc6213eac3 16. ? @ 0x00007fbc621d0850 2025.07.28 11:58:44.788461 [ 4963 ] {defc2888-4f8c-4e57-ac4c-e4173cee2b91} executeQuery: Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01103_optimize_drop_race_zookeeper_test_15/concurrent_optimize_table/replicas/1). (TABLE_IS_READ_ONLY) (version 25.3.6.10636.altinitytest (altinity build)) (from [::1]:51470) (comment: 01103_optimize_drop_race_zookeeper.sh) (query 1, line 1) (in query: OPTIMIZE TABLE concurrent_optimize_table FINAL), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000a9b78ab 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:5935: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000015e86144 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:6112: DB::StorageReplicatedMergeTree::optimize(std::shared_ptr const&, std::shared_ptr const&, std::shared_ptr const&, bool, bool, std::vector> const&, bool, std::shared_ptr) @ 0x0000000015f21f2c 6. /build/src/Interpreters/InterpreterOptimizeQuery.cpp:84: DB::InterpreterOptimizeQuery::execute() @ 0x0000000014cd782e 7. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88dc9 8. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 9. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 10. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 11. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 12. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 13. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 14. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 15. ? @ 0x00007fbc6213eac3 16. ? @ 0x00007fbc621d0850 2025.07.28 11:58:44.806255 [ 4963 ] {} TCPHandler: Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01103_optimize_drop_race_zookeeper_test_15/concurrent_optimize_table/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000a9b78ab 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:5935: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000015e86144 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:6112: DB::StorageReplicatedMergeTree::optimize(std::shared_ptr const&, std::shared_ptr const&, std::shared_ptr const&, bool, bool, std::vector> const&, bool, std::shared_ptr) @ 0x0000000015f21f2c 6. /build/src/Interpreters/InterpreterOptimizeQuery.cpp:84: DB::InterpreterOptimizeQuery::execute() @ 0x0000000014cd782e 7. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88dc9 8. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 9. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 10. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 11. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 12. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 13. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 14. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 15. ? @ 0x00007fbc6213eac3 16. ? @ 0x00007fbc621d0850 2025.07.28 11:58:44.870322 [ 5951 ] {05db085b-5ea4-4c53-bc25-8b6f6646f9e4} executeQuery: Code: 57. DB::Exception: Table test_15.concurrent_optimize_table already exists. (TABLE_ALREADY_EXISTS) (version 25.3.6.10636.altinitytest (altinity build)) (from [::1]:51266) (comment: 01103_optimize_drop_race_zookeeper.sh) (query 2, line 2) (in query: CREATE TABLE concurrent_optimize_table (`a` UInt8, `b` Int16, `c` Float32, `d` String, `e` Array(UInt8), `f` Nullable(UUID), `g` Tuple(UInt8, UInt16)) ENGINE = ReplicatedMergeTree('/clickhouse/tables/01103_optimize_drop_race_zookeeper_test_15/concurrent_optimize_table', '1') PARTITION BY b % 10 ORDER BY a SETTINGS old_parts_lifetime = 1, cleanup_delay_period = 0, cleanup_delay_period_random_add = 0, cleanup_thread_preferred_points_per_iteration = 0, index_granularity = 31489, 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 = 20868213, compact_parts_max_bytes_to_buffer = 108362629, compact_parts_max_granules_to_buffer = 1, compact_parts_merge_max_bytes_to_prefetch_part = 18898448, merge_max_block_size = 13220, prefer_fetch_merged_part_size_threshold = 1, vertical_merge_algorithm_min_rows_to_activate = 1000000, vertical_merge_algorithm_min_columns_to_activate = 76, min_merge_bytes_to_use_direct_io = 10737418240, index_granularity_bytes = 7046892, use_const_adaptive_granularity = false, 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 = true, cache_populated_by_fetch = false, marks_compress_block_size = 84392, primary_key_compress_block_size = 23861, 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. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000a06a8eb 4. /build/src/Interpreters/InterpreterCreateQuery.cpp:1824: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x0000000014901d53 5. /build/src/Interpreters/InterpreterCreateQuery.cpp:1743: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000148f9aa9 6. /build/src/Interpreters/InterpreterCreateQuery.cpp:2352: DB::InterpreterCreateQuery::execute() @ 0x0000000014905a41 7. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88dc9 8. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 9. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 10. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 11. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 12. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 13. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 14. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 15. ? @ 0x00007fbc6213eac3 16. ? @ 0x00007fbc621d0850 2025.07.28 11:58:44.879071 [ 17232 ] {427e7618-dc21-45a3-ae90-845069cc952d} executeQuery: Code: 57. DB::Exception: Table test_15.concurrent_optimize_table already exists. (TABLE_ALREADY_EXISTS) (version 25.3.6.10636.altinitytest (altinity build)) (from [::1]:51140) (comment: 01103_optimize_drop_race_zookeeper.sh) (query 2, line 2) (in query: CREATE TABLE concurrent_optimize_table (`a` UInt8, `b` Int16, `c` Float32, `d` String, `e` Array(UInt8), `f` Nullable(UUID), `g` Tuple(UInt8, UInt16)) ENGINE = ReplicatedMergeTree('/clickhouse/tables/01103_optimize_drop_race_zookeeper_test_15/concurrent_optimize_table', '1') PARTITION BY b % 10 ORDER BY a SETTINGS old_parts_lifetime = 1, cleanup_delay_period = 0, cleanup_delay_period_random_add = 0, cleanup_thread_preferred_points_per_iteration = 0, index_granularity = 31489, 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 = 20868213, compact_parts_max_bytes_to_buffer = 108362629, compact_parts_max_granules_to_buffer = 1, compact_parts_merge_max_bytes_to_prefetch_part = 18898448, merge_max_block_size = 13220, prefer_fetch_merged_part_size_threshold = 1, vertical_merge_algorithm_min_rows_to_activate = 1000000, vertical_merge_algorithm_min_columns_to_activate = 76, min_merge_bytes_to_use_direct_io = 10737418240, index_granularity_bytes = 7046892, use_const_adaptive_granularity = false, 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 = true, cache_populated_by_fetch = false, marks_compress_block_size = 84392, primary_key_compress_block_size = 23861, 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. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000a06a8eb 4. /build/src/Interpreters/InterpreterCreateQuery.cpp:1824: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x0000000014901d53 5. /build/src/Interpreters/InterpreterCreateQuery.cpp:1743: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000148f9aa9 6. /build/src/Interpreters/InterpreterCreateQuery.cpp:2352: DB::InterpreterCreateQuery::execute() @ 0x0000000014905a41 7. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88dc9 8. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 9. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 10. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 11. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 12. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 13. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 14. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 15. ? @ 0x00007fbc6213eac3 16. ? @ 0x00007fbc621d0850 2025.07.28 11:58:44.885837 [ 5951 ] {} TCPHandler: Code: 57. DB::Exception: Table test_15.concurrent_optimize_table already exists. (TABLE_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000a06a8eb 4. /build/src/Interpreters/InterpreterCreateQuery.cpp:1824: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x0000000014901d53 5. /build/src/Interpreters/InterpreterCreateQuery.cpp:1743: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000148f9aa9 6. /build/src/Interpreters/InterpreterCreateQuery.cpp:2352: DB::InterpreterCreateQuery::execute() @ 0x0000000014905a41 7. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88dc9 8. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 9. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 10. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 11. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 12. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 13. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 14. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 15. ? @ 0x00007fbc6213eac3 16. ? @ 0x00007fbc621d0850 2025.07.28 11:58:44.984405 [ 17232 ] {} TCPHandler: Code: 57. DB::Exception: Table test_15.concurrent_optimize_table already exists. (TABLE_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000a06a8eb 4. /build/src/Interpreters/InterpreterCreateQuery.cpp:1824: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x0000000014901d53 5. /build/src/Interpreters/InterpreterCreateQuery.cpp:1743: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000148f9aa9 6. /build/src/Interpreters/InterpreterCreateQuery.cpp:2352: DB::InterpreterCreateQuery::execute() @ 0x0000000014905a41 7. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88dc9 8. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 9. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 10. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 11. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 12. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 13. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 14. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 15. ? @ 0x00007fbc6213eac3 16. ? @ 0x00007fbc621d0850 2025.07.28 11:58:45.022068 [ 17203 ] {6d5dc9c0-d53a-47c1-8523-70d8f194c106} executeQuery: Code: 57. DB::Exception: Table test_15.concurrent_optimize_table already exists. (TABLE_ALREADY_EXISTS) (version 25.3.6.10636.altinitytest (altinity build)) (from [::1]:51346) (comment: 01103_optimize_drop_race_zookeeper.sh) (query 2, line 2) (in query: CREATE TABLE concurrent_optimize_table (`a` UInt8, `b` Int16, `c` Float32, `d` String, `e` Array(UInt8), `f` Nullable(UUID), `g` Tuple(UInt8, UInt16)) ENGINE = ReplicatedMergeTree('/clickhouse/tables/01103_optimize_drop_race_zookeeper_test_15/concurrent_optimize_table', '1') PARTITION BY b % 10 ORDER BY a SETTINGS old_parts_lifetime = 1, cleanup_delay_period = 0, cleanup_delay_period_random_add = 0, cleanup_thread_preferred_points_per_iteration = 0, index_granularity = 31489, 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 = 20868213, compact_parts_max_bytes_to_buffer = 108362629, compact_parts_max_granules_to_buffer = 1, compact_parts_merge_max_bytes_to_prefetch_part = 18898448, merge_max_block_size = 13220, prefer_fetch_merged_part_size_threshold = 1, vertical_merge_algorithm_min_rows_to_activate = 1000000, vertical_merge_algorithm_min_columns_to_activate = 76, min_merge_bytes_to_use_direct_io = 10737418240, index_granularity_bytes = 7046892, use_const_adaptive_granularity = false, 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 = true, cache_populated_by_fetch = false, marks_compress_block_size = 84392, primary_key_compress_block_size = 23861, 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. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000a06a8eb 4. /build/src/Interpreters/InterpreterCreateQuery.cpp:1824: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x0000000014901d53 5. /build/src/Interpreters/InterpreterCreateQuery.cpp:1743: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000148f9aa9 6. /build/src/Interpreters/InterpreterCreateQuery.cpp:2352: DB::InterpreterCreateQuery::execute() @ 0x0000000014905a41 7. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88dc9 8. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 9. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 10. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 11. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 12. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 13. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 14. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 15. ? @ 0x00007fbc6213eac3 16. ? @ 0x00007fbc621d0850 2025.07.28 11:58:45.088195 [ 17203 ] {} TCPHandler: Code: 57. DB::Exception: Table test_15.concurrent_optimize_table already exists. (TABLE_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000a06a8eb 4. /build/src/Interpreters/InterpreterCreateQuery.cpp:1824: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x0000000014901d53 5. /build/src/Interpreters/InterpreterCreateQuery.cpp:1743: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000148f9aa9 6. /build/src/Interpreters/InterpreterCreateQuery.cpp:2352: DB::InterpreterCreateQuery::execute() @ 0x0000000014905a41 7. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88dc9 8. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 9. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 10. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 11. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 12. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 13. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 14. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 15. ? @ 0x00007fbc6213eac3 16. ? @ 0x00007fbc621d0850 2025.07.28 11:58:45.449527 [ 3977 ] {} test_13.rmt2 (7f9b740d-015c-470e-8cc6-8ba33be0dc63): auto DB::StorageReplicatedMergeTree::processQueueEntry(ReplicatedMergeTreeQueue::SelectedEntryPtr)::(anonymous class)::operator()(LogEntryPtr &) const: Code: 86. DB::HTTPException: Received error from remote server http://146b4357c08d:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Ftest%2F01165%2Ftest_13%2Frmt%2Freplicas%2F1&part=20250728_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.6.10636.altinitytest (altinity build)) '. (RECEIVED_ERROR_FROM_REMOTE_IO_SERVER), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.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 const&, int&&, String const&, unsigned long&&, String const&) @ 0x000000000feda8d9 4. /build/src/IO/HTTPCommon.cpp:104: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x000000000feda6e2 5. /build/src/IO/HTTPCommon.cpp:93: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x000000000feda537 6. /build/src/IO/ReadWriteBufferFromHTTP.cpp:277: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x000000001184a4c4 7. /build/src/IO/ReadWriteBufferFromHTTP.cpp:285: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x000000001184a615 8. /build/src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x000000001184ae59 9. /build/src/IO/ReadWriteBufferFromHTTP.cpp:472: void std::__function::__policy_invoker::__call_impl[abi:se190107]>(std::__function::__policy_storage const*) @ 0x000000001184cedd 10. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001184858b 11. /build/src/IO/ReadWriteBufferFromHTTP.cpp:465: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x000000001184bf0b 12. /build/src/IO/ReadBuffer.h:60: DB::ReadBuffer::next() @ 0x000000000a148c7b 13. /build/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) @ 0x0000000011849fb2 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]>&)>&, 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&) @ 0x0000000011841980 15. /build/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) @ 0x000000001621208e 16. /build/src/Storages/StorageReplicatedMergeTree.cpp:5228: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl[abi:se190107] const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000015f9a5fe 17. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000015ed8bfd 18. /build/src/Storages/StorageReplicatedMergeTree.cpp:2514: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x0000000015ec9aab 19. /build/src/Storages/StorageReplicatedMergeTree.cpp:2349: DB::StorageReplicatedMergeTree::executeLogEntry(DB::ReplicatedMergeTreeLogEntry&) @ 0x0000000015eba91b 20. /build/src/Storages/StorageReplicatedMergeTree.cpp:3876: bool std::__function::__policy_invoker&)>::__call_impl[abi:se190107])::$_1, bool (std::shared_ptr&)>>(std::__function::__policy_storage const*, std::shared_ptr&) @ 0x0000000015f9837e 21. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000165d6fc3 22. /build/src/Storages/StorageReplicatedMergeTree.cpp:3872: DB::StorageReplicatedMergeTree::processQueueEntry(std::shared_ptr) @ 0x0000000015efc18a 23. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001624c1b2 24. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000162f9c70 25. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x00000000162fa55a 26. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc6653 27. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000000fccc4c3 28. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc3d92 29. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fcca080 30. ? @ 0x00007fbc6213eac3 31. ? @ 0x00007fbc621d0850 (version 25.3.6.10636.altinitytest (altinity build)) 2025.07.28 11:58:45.641823 [ 3960 ] {} test_13.rmt2 (7f9b740d-015c-470e-8cc6-8ba33be0dc63): auto DB::StorageReplicatedMergeTree::processQueueEntry(ReplicatedMergeTreeQueue::SelectedEntryPtr)::(anonymous class)::operator()(LogEntryPtr &) const: Code: 86. DB::HTTPException: Received error from remote server http://146b4357c08d:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Ftest%2F01165%2Ftest_13%2Frmt%2Freplicas%2F1&part=20250728_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.6.10636.altinitytest (altinity build)) '. (RECEIVED_ERROR_FROM_REMOTE_IO_SERVER), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.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 const&, int&&, String const&, unsigned long&&, String const&) @ 0x000000000feda8d9 4. /build/src/IO/HTTPCommon.cpp:104: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x000000000feda6e2 5. /build/src/IO/HTTPCommon.cpp:93: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x000000000feda537 6. /build/src/IO/ReadWriteBufferFromHTTP.cpp:277: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x000000001184a4c4 7. /build/src/IO/ReadWriteBufferFromHTTP.cpp:285: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x000000001184a615 8. /build/src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x000000001184ae59 9. /build/src/IO/ReadWriteBufferFromHTTP.cpp:472: void std::__function::__policy_invoker::__call_impl[abi:se190107]>(std::__function::__policy_storage const*) @ 0x000000001184cedd 10. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001184858b 11. /build/src/IO/ReadWriteBufferFromHTTP.cpp:465: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x000000001184bf0b 12. /build/src/IO/ReadBuffer.h:60: DB::ReadBuffer::next() @ 0x000000000a148c7b 13. /build/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) @ 0x0000000011849fb2 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]>&)>&, 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&) @ 0x0000000011841980 15. /build/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) @ 0x000000001621208e 16. /build/src/Storages/StorageReplicatedMergeTree.cpp:5228: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl[abi:se190107] const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000015f9a5fe 17. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000015ed8bfd 18. /build/src/Storages/StorageReplicatedMergeTree.cpp:2514: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x0000000015ec9aab 19. /build/src/Storages/StorageReplicatedMergeTree.cpp:2349: DB::StorageReplicatedMergeTree::executeLogEntry(DB::ReplicatedMergeTreeLogEntry&) @ 0x0000000015eba91b 20. /build/src/Storages/StorageReplicatedMergeTree.cpp:3876: bool std::__function::__policy_invoker&)>::__call_impl[abi:se190107])::$_1, bool (std::shared_ptr&)>>(std::__function::__policy_storage const*, std::shared_ptr&) @ 0x0000000015f9837e 21. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000165d6fc3 22. /build/src/Storages/StorageReplicatedMergeTree.cpp:3872: DB::StorageReplicatedMergeTree::processQueueEntry(std::shared_ptr) @ 0x0000000015efc18a 23. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001624c1b2 24. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000162f9c70 25. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x00000000162fa55a 26. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc6653 27. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000000fccc4c3 28. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc3d92 29. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fcca080 30. ? @ 0x00007fbc6213eac3 31. ? @ 0x00007fbc621d0850 (version 25.3.6.10636.altinitytest (altinity build)) 2025.07.28 11:58:45.762281 [ 17203 ] {03a78655-e456-447f-a260-630d5e624d30} executeQuery: Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01103_optimize_drop_race_zookeeper_test_15/concurrent_optimize_table/replicas/1). (TABLE_IS_READ_ONLY) (version 25.3.6.10636.altinitytest (altinity build)) (from [::1]:51544) (comment: 01103_optimize_drop_race_zookeeper.sh) (query 1, line 1) (in query: OPTIMIZE TABLE concurrent_optimize_table FINAL), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000a9b78ab 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:5935: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000015e86144 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:6112: DB::StorageReplicatedMergeTree::optimize(std::shared_ptr const&, std::shared_ptr const&, std::shared_ptr const&, bool, bool, std::vector> const&, bool, std::shared_ptr) @ 0x0000000015f21f2c 6. /build/src/Interpreters/InterpreterOptimizeQuery.cpp:84: DB::InterpreterOptimizeQuery::execute() @ 0x0000000014cd782e 7. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88dc9 8. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 9. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 10. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 11. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 12. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 13. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 14. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 15. ? @ 0x00007fbc6213eac3 16. ? @ 0x00007fbc621d0850 2025.07.28 11:58:45.788748 [ 17203 ] {} TCPHandler: Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01103_optimize_drop_race_zookeeper_test_15/concurrent_optimize_table/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000a9b78ab 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:5935: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000015e86144 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:6112: DB::StorageReplicatedMergeTree::optimize(std::shared_ptr const&, std::shared_ptr const&, std::shared_ptr const&, bool, bool, std::vector> const&, bool, std::shared_ptr) @ 0x0000000015f21f2c 6. /build/src/Interpreters/InterpreterOptimizeQuery.cpp:84: DB::InterpreterOptimizeQuery::execute() @ 0x0000000014cd782e 7. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88dc9 8. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 9. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 10. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 11. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 12. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 13. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 14. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 15. ? @ 0x00007fbc6213eac3 16. ? @ 0x00007fbc621d0850 2025.07.28 11:58:45.800616 [ 5327 ] {60706530-6a29-413e-8368-e33f31532433} executeQuery: Code: 242. DB::Exception: Table is in readonly mode due to shutdown: replica_path=/clickhouse/tables/01103_optimize_drop_race_zookeeper_test_15/concurrent_optimize_table/replicas/1. (TABLE_IS_READ_ONLY) (version 25.3.6.10636.altinitytest (altinity build)) (from [::1]:51454) (comment: 01103_optimize_drop_race_zookeeper.sh) (query 1, line 1) (in query: INSERT INTO concurrent_optimize_table SELECT rand(1), rand(2), 1 / rand(3), toString(rand(4)), [rand(5), rand(6)], rand(7) % 2 ? NULL : generateUUIDv4(), (rand(8), rand(9)) FROM numbers(10000)), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000a9b78ab 4. /build/src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:866: DB::ReplicatedMergeTreeSinkImpl::commitPart(std::shared_ptr const&, std::shared_ptr&, String const&, unsigned long)::'lambda1'()::operator()() const @ 0x000000001660eed7 5. /build/src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:1124: DB::ReplicatedMergeTreeSinkImpl::commitPart(std::shared_ptr const&, std::shared_ptr&, String const&, unsigned long)::'lambda2'()::operator()() const @ 0x000000001660d1f2 6. /build/src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:1157: void DB::ZooKeeperRetriesControl::retryLoop::commitPart(std::shared_ptr const&, std::shared_ptr&, String const&, unsigned long)::'lambda3'()&, void DB::ZooKeeperRetriesControl::retryLoop::commitPart(std::shared_ptr const&, std::shared_ptr&, String const&, unsigned long)::'lambda3'()>(DB::ReplicatedMergeTreeSinkImpl::commitPart(std::shared_ptr const&, std::shared_ptr&, String const&, unsigned long)::'lambda3'()&&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::commitPart(std::shared_ptr const&, std::shared_ptr&, String const&, unsigned long)::'lambda3'()&&, void DB::ZooKeeperRetriesControl::retryLoop::commitPart(std::shared_ptr const&, std::shared_ptr&, String const&, unsigned long)::'lambda3'()>(DB::ReplicatedMergeTreeSinkImpl::commitPart(std::shared_ptr const&, std::shared_ptr&, String const&, unsigned long)::'lambda3'()&&)::'lambda'()&&) @ 0x000000001660d07f 7. /build/src/Common/ZooKeeper/ZooKeeperRetries.h:52: DB::ReplicatedMergeTreeSinkImpl::commitPart(std::shared_ptr const&, std::shared_ptr&, String const&, unsigned long) @ 0x00000000165fd951 8. /build/src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:492: DB::ReplicatedMergeTreeSinkImpl::finishDelayedChunk(std::shared_ptr const&) @ 0x00000000165f277d 9. /build/src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:437: DB::ReplicatedMergeTreeSinkImpl::consume(DB::Chunk&) @ 0x00000000165fbd00 10. /build/src/Processors/Sinks/SinkToStorage.cpp:10: DB::SinkToStorage::onConsume(DB::Chunk) @ 0x0000000016cee093 11. /build/src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: void std::__function::__policy_invoker::__call_impl[abi:se190107]>(std::__function::__policy_storage const*) @ 0x0000000016c0ad89 12. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000016c0abf5 13. /build/src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: DB::ExceptionKeepingTransform::work() @ 0x0000000016c0a6fe 14. /build/src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x00000000169bd00f 15. /build/src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x00000000169b2105 16. /build/src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeSingleThread(unsigned long) @ 0x00000000169b23be 17. /build/src/Processors/Executors/PipelineExecutor.cpp:416: void std::__function::__policy_invoker::__call_impl[abi:se190107]>(std::__function::__policy_storage const*) @ 0x00000000169b2e3f 18. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc6653 19. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000000fccc4c3 20. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc3d92 21. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fcca080 22. ? @ 0x00007fbc6213eac3 23. ? @ 0x00007fbc621d0850 2025.07.28 11:58:45.836066 [ 11826 ] {1d88c8ac-0f43-4733-86ab-f3604485781b} executeQuery: Code: 242. DB::Exception: Table is in readonly mode due to shutdown: replica_path=/clickhouse/tables/01103_optimize_drop_race_zookeeper_test_15/concurrent_optimize_table/replicas/1. (TABLE_IS_READ_ONLY) (version 25.3.6.10636.altinitytest (altinity build)) (from [::1]:51476) (comment: 01103_optimize_drop_race_zookeeper.sh) (query 1, line 1) (in query: INSERT INTO concurrent_optimize_table SELECT rand(1), rand(2), 1 / rand(3), toString(rand(4)), [rand(5), rand(6)], rand(7) % 2 ? NULL : generateUUIDv4(), (rand(8), rand(9)) FROM numbers(10000)), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000a9b78ab 4. /build/src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:866: DB::ReplicatedMergeTreeSinkImpl::commitPart(std::shared_ptr const&, std::shared_ptr&, String const&, unsigned long)::'lambda1'()::operator()() const @ 0x000000001660eed7 5. /build/src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:1124: DB::ReplicatedMergeTreeSinkImpl::commitPart(std::shared_ptr const&, std::shared_ptr&, String const&, unsigned long)::'lambda2'()::operator()() const @ 0x000000001660d1f2 6. /build/src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:1157: void DB::ZooKeeperRetriesControl::retryLoop::commitPart(std::shared_ptr const&, std::shared_ptr&, String const&, unsigned long)::'lambda3'()&, void DB::ZooKeeperRetriesControl::retryLoop::commitPart(std::shared_ptr const&, std::shared_ptr&, String const&, unsigned long)::'lambda3'()>(DB::ReplicatedMergeTreeSinkImpl::commitPart(std::shared_ptr const&, std::shared_ptr&, String const&, unsigned long)::'lambda3'()&&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::commitPart(std::shared_ptr const&, std::shared_ptr&, String const&, unsigned long)::'lambda3'()&&, void DB::ZooKeeperRetriesControl::retryLoop::commitPart(std::shared_ptr const&, std::shared_ptr&, String const&, unsigned long)::'lambda3'()>(DB::ReplicatedMergeTreeSinkImpl::commitPart(std::shared_ptr const&, std::shared_ptr&, String const&, unsigned long)::'lambda3'()&&)::'lambda'()&&) @ 0x000000001660d07f 7. /build/src/Common/ZooKeeper/ZooKeeperRetries.h:52: DB::ReplicatedMergeTreeSinkImpl::commitPart(std::shared_ptr const&, std::shared_ptr&, String const&, unsigned long) @ 0x00000000165fd951 8. /build/src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:492: DB::ReplicatedMergeTreeSinkImpl::finishDelayedChunk(std::shared_ptr const&) @ 0x00000000165f277d 9. /build/src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:437: DB::ReplicatedMergeTreeSinkImpl::consume(DB::Chunk&) @ 0x00000000165fbd00 10. /build/src/Processors/Sinks/SinkToStorage.cpp:10: DB::SinkToStorage::onConsume(DB::Chunk) @ 0x0000000016cee093 11. /build/src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: void std::__function::__policy_invoker::__call_impl[abi:se190107]>(std::__function::__policy_storage const*) @ 0x0000000016c0ad89 12. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000016c0abf5 13. /build/src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: DB::ExceptionKeepingTransform::work() @ 0x0000000016c0a6fe 14. /build/src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x00000000169bd00f 15. /build/src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x00000000169b2105 16. /build/src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeSingleThread(unsigned long) @ 0x00000000169b23be 17. /build/src/Processors/Executors/PipelineExecutor.cpp:416: void std::__function::__policy_invoker::__call_impl[abi:se190107]>(std::__function::__policy_storage const*) @ 0x00000000169b2e3f 18. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc6653 19. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000000fccc4c3 20. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc3d92 21. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fcca080 22. ? @ 0x00007fbc6213eac3 23. ? @ 0x00007fbc621d0850 2025.07.28 11:58:45.841243 [ 5327 ] {} TCPHandler: Code: 242. DB::Exception: Table is in readonly mode due to shutdown: replica_path=/clickhouse/tables/01103_optimize_drop_race_zookeeper_test_15/concurrent_optimize_table/replicas/1. (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000a9b78ab 4. /build/src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:866: DB::ReplicatedMergeTreeSinkImpl::commitPart(std::shared_ptr const&, std::shared_ptr&, String const&, unsigned long)::'lambda1'()::operator()() const @ 0x000000001660eed7 5. /build/src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:1124: DB::ReplicatedMergeTreeSinkImpl::commitPart(std::shared_ptr const&, std::shared_ptr&, String const&, unsigned long)::'lambda2'()::operator()() const @ 0x000000001660d1f2 6. /build/src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:1157: void DB::ZooKeeperRetriesControl::retryLoop::commitPart(std::shared_ptr const&, std::shared_ptr&, String const&, unsigned long)::'lambda3'()&, void DB::ZooKeeperRetriesControl::retryLoop::commitPart(std::shared_ptr const&, std::shared_ptr&, String const&, unsigned long)::'lambda3'()>(DB::ReplicatedMergeTreeSinkImpl::commitPart(std::shared_ptr const&, std::shared_ptr&, String const&, unsigned long)::'lambda3'()&&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::commitPart(std::shared_ptr const&, std::shared_ptr&, String const&, unsigned long)::'lambda3'()&&, void DB::ZooKeeperRetriesControl::retryLoop::commitPart(std::shared_ptr const&, std::shared_ptr&, String const&, unsigned long)::'lambda3'()>(DB::ReplicatedMergeTreeSinkImpl::commitPart(std::shared_ptr const&, std::shared_ptr&, String const&, unsigned long)::'lambda3'()&&)::'lambda'()&&) @ 0x000000001660d07f 7. /build/src/Common/ZooKeeper/ZooKeeperRetries.h:52: DB::ReplicatedMergeTreeSinkImpl::commitPart(std::shared_ptr const&, std::shared_ptr&, String const&, unsigned long) @ 0x00000000165fd951 8. /build/src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:492: DB::ReplicatedMergeTreeSinkImpl::finishDelayedChunk(std::shared_ptr const&) @ 0x00000000165f277d 9. /build/src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:437: DB::ReplicatedMergeTreeSinkImpl::consume(DB::Chunk&) @ 0x00000000165fbd00 10. /build/src/Processors/Sinks/SinkToStorage.cpp:10: DB::SinkToStorage::onConsume(DB::Chunk) @ 0x0000000016cee093 11. /build/src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: void std::__function::__policy_invoker::__call_impl[abi:se190107]>(std::__function::__policy_storage const*) @ 0x0000000016c0ad89 12. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000016c0abf5 13. /build/src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: DB::ExceptionKeepingTransform::work() @ 0x0000000016c0a6fe 14. /build/src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x00000000169bd00f 15. /build/src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x00000000169b2105 16. /build/src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeSingleThread(unsigned long) @ 0x00000000169b23be 17. /build/src/Processors/Executors/PipelineExecutor.cpp:416: void std::__function::__policy_invoker::__call_impl[abi:se190107]>(std::__function::__policy_storage const*) @ 0x00000000169b2e3f 18. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc6653 19. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000000fccc4c3 20. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc3d92 21. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fcca080 22. ? @ 0x00007fbc6213eac3 23. ? @ 0x00007fbc621d0850 Job's origin stack trace: 0. /build/src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000000fc33b84 1. /build/src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000000fcc2ea7 2. /build/src/Common/ThreadPool.cpp:401: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fcc7f1c 3. /build/src/Common/ThreadPool.cpp:494: ThreadPoolImpl>::scheduleOrThrowOnError(std::function, Priority) @ 0x000000000fcc7a0e 4. /build/src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::spawnThreadsImpl() @ 0x00000000169b2c0c 5. /build/src/Processors/Executors/PipelineExecutor.cpp:394: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x00000000169b0ba7 6. /build/src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x00000000169b03f4 7. /build/src/Processors/Executors/CompletedPipelineExecutor.cpp:42: void std::__function::__policy_invoker::__call_impl[abi:se190107]::ThreadFromGlobalPoolImpl(DB::CompletedPipelineExecutor::execute()::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169af7e1 8. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc3d92 9. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fcca080 10. ? @ 0x00007fbc6213eac3 11. ? @ 0x00007fbc621d0850 Job's origin stack trace: 0. /build/src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000000fc33b84 1. /build/src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000000fcc2ea7 2. /build/src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fcc535c 3. /build/src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000000fcc584d 4. /build/src/Common/ThreadPool.h:279: DB::CompletedPipelineExecutor::execute() @ 0x00000000169af267 5. /build/src/Server/TCPHandler.cpp:707: DB::TCPHandler::runImpl() @ 0x00000000168e6b2e 6. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 7. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 8. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 9. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 10. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 11. ? @ 0x00007fbc6213eac3 12. ? @ 0x00007fbc621d0850 2025.07.28 11:58:45.900491 [ 11826 ] {} TCPHandler: Code: 242. DB::Exception: Table is in readonly mode due to shutdown: replica_path=/clickhouse/tables/01103_optimize_drop_race_zookeeper_test_15/concurrent_optimize_table/replicas/1. (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000a9b78ab 4. /build/src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:866: DB::ReplicatedMergeTreeSinkImpl::commitPart(std::shared_ptr const&, std::shared_ptr&, String const&, unsigned long)::'lambda1'()::operator()() const @ 0x000000001660eed7 5. /build/src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:1124: DB::ReplicatedMergeTreeSinkImpl::commitPart(std::shared_ptr const&, std::shared_ptr&, String const&, unsigned long)::'lambda2'()::operator()() const @ 0x000000001660d1f2 6. /build/src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:1157: void DB::ZooKeeperRetriesControl::retryLoop::commitPart(std::shared_ptr const&, std::shared_ptr&, String const&, unsigned long)::'lambda3'()&, void DB::ZooKeeperRetriesControl::retryLoop::commitPart(std::shared_ptr const&, std::shared_ptr&, String const&, unsigned long)::'lambda3'()>(DB::ReplicatedMergeTreeSinkImpl::commitPart(std::shared_ptr const&, std::shared_ptr&, String const&, unsigned long)::'lambda3'()&&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::commitPart(std::shared_ptr const&, std::shared_ptr&, String const&, unsigned long)::'lambda3'()&&, void DB::ZooKeeperRetriesControl::retryLoop::commitPart(std::shared_ptr const&, std::shared_ptr&, String const&, unsigned long)::'lambda3'()>(DB::ReplicatedMergeTreeSinkImpl::commitPart(std::shared_ptr const&, std::shared_ptr&, String const&, unsigned long)::'lambda3'()&&)::'lambda'()&&) @ 0x000000001660d07f 7. /build/src/Common/ZooKeeper/ZooKeeperRetries.h:52: DB::ReplicatedMergeTreeSinkImpl::commitPart(std::shared_ptr const&, std::shared_ptr&, String const&, unsigned long) @ 0x00000000165fd951 8. /build/src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:492: DB::ReplicatedMergeTreeSinkImpl::finishDelayedChunk(std::shared_ptr const&) @ 0x00000000165f277d 9. /build/src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:437: DB::ReplicatedMergeTreeSinkImpl::consume(DB::Chunk&) @ 0x00000000165fbd00 10. /build/src/Processors/Sinks/SinkToStorage.cpp:10: DB::SinkToStorage::onConsume(DB::Chunk) @ 0x0000000016cee093 11. /build/src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: void std::__function::__policy_invoker::__call_impl[abi:se190107]>(std::__function::__policy_storage const*) @ 0x0000000016c0ad89 12. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000016c0abf5 13. /build/src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: DB::ExceptionKeepingTransform::work() @ 0x0000000016c0a6fe 14. /build/src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x00000000169bd00f 15. /build/src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x00000000169b2105 16. /build/src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeSingleThread(unsigned long) @ 0x00000000169b23be 17. /build/src/Processors/Executors/PipelineExecutor.cpp:416: void std::__function::__policy_invoker::__call_impl[abi:se190107]>(std::__function::__policy_storage const*) @ 0x00000000169b2e3f 18. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc6653 19. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000000fccc4c3 20. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc3d92 21. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fcca080 22. ? @ 0x00007fbc6213eac3 23. ? @ 0x00007fbc621d0850 Job's origin stack trace: 0. /build/src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000000fc33b84 1. /build/src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000000fcc2ea7 2. /build/src/Common/ThreadPool.cpp:401: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fcc7f1c 3. /build/src/Common/ThreadPool.cpp:494: ThreadPoolImpl>::scheduleOrThrowOnError(std::function, Priority) @ 0x000000000fcc7a0e 4. /build/src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::spawnThreadsImpl() @ 0x00000000169b2c0c 5. /build/src/Processors/Executors/PipelineExecutor.cpp:394: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x00000000169b0ba7 6. /build/src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x00000000169b03f4 7. /build/src/Processors/Executors/CompletedPipelineExecutor.cpp:42: void std::__function::__policy_invoker::__call_impl[abi:se190107]::ThreadFromGlobalPoolImpl(DB::CompletedPipelineExecutor::execute()::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169af7e1 8. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc3d92 9. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fcca080 10. ? @ 0x00007fbc6213eac3 11. ? @ 0x00007fbc621d0850 Job's origin stack trace: 0. /build/src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000000fc33b84 1. /build/src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000000fcc2ea7 2. /build/src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fcc535c 3. /build/src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000000fcc584d 4. /build/src/Common/ThreadPool.h:279: DB::CompletedPipelineExecutor::execute() @ 0x00000000169af267 5. /build/src/Server/TCPHandler.cpp:707: DB::TCPHandler::runImpl() @ 0x00000000168e6b2e 6. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 7. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 8. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 9. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 10. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 11. ? @ 0x00007fbc6213eac3 12. ? @ 0x00007fbc621d0850 2025.07.28 11:58:45.912478 [ 7625 ] {39736644-680a-4fc4-a2d1-bb7d53a690e0} executeQuery: Code: 242. DB::Exception: Table is in readonly mode due to shutdown: replica_path=/clickhouse/tables/01103_optimize_drop_race_zookeeper_test_15/concurrent_optimize_table/replicas/1. (TABLE_IS_READ_ONLY) (version 25.3.6.10636.altinitytest (altinity build)) (from [::1]:51444) (comment: 01103_optimize_drop_race_zookeeper.sh) (query 1, line 1) (in query: INSERT INTO concurrent_optimize_table SELECT rand(1), rand(2), 1 / rand(3), toString(rand(4)), [rand(5), rand(6)], rand(7) % 2 ? NULL : generateUUIDv4(), (rand(8), rand(9)) FROM numbers(10000)), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000a9b78ab 4. /build/src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:866: DB::ReplicatedMergeTreeSinkImpl::commitPart(std::shared_ptr const&, std::shared_ptr&, String const&, unsigned long)::'lambda1'()::operator()() const @ 0x000000001660eed7 5. /build/src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:1124: DB::ReplicatedMergeTreeSinkImpl::commitPart(std::shared_ptr const&, std::shared_ptr&, String const&, unsigned long)::'lambda2'()::operator()() const @ 0x000000001660d1f2 6. /build/src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:1157: void DB::ZooKeeperRetriesControl::retryLoop::commitPart(std::shared_ptr const&, std::shared_ptr&, String const&, unsigned long)::'lambda3'()&, void DB::ZooKeeperRetriesControl::retryLoop::commitPart(std::shared_ptr const&, std::shared_ptr&, String const&, unsigned long)::'lambda3'()>(DB::ReplicatedMergeTreeSinkImpl::commitPart(std::shared_ptr const&, std::shared_ptr&, String const&, unsigned long)::'lambda3'()&&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::commitPart(std::shared_ptr const&, std::shared_ptr&, String const&, unsigned long)::'lambda3'()&&, void DB::ZooKeeperRetriesControl::retryLoop::commitPart(std::shared_ptr const&, std::shared_ptr&, String const&, unsigned long)::'lambda3'()>(DB::ReplicatedMergeTreeSinkImpl::commitPart(std::shared_ptr const&, std::shared_ptr&, String const&, unsigned long)::'lambda3'()&&)::'lambda'()&&) @ 0x000000001660d07f 7. /build/src/Common/ZooKeeper/ZooKeeperRetries.h:52: DB::ReplicatedMergeTreeSinkImpl::commitPart(std::shared_ptr const&, std::shared_ptr&, String const&, unsigned long) @ 0x00000000165fd951 8. /build/src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:492: DB::ReplicatedMergeTreeSinkImpl::finishDelayedChunk(std::shared_ptr const&) @ 0x00000000165f277d 9. /build/src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:437: DB::ReplicatedMergeTreeSinkImpl::consume(DB::Chunk&) @ 0x00000000165fbd00 10. /build/src/Processors/Sinks/SinkToStorage.cpp:10: DB::SinkToStorage::onConsume(DB::Chunk) @ 0x0000000016cee093 11. /build/src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: void std::__function::__policy_invoker::__call_impl[abi:se190107]>(std::__function::__policy_storage const*) @ 0x0000000016c0ad89 12. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000016c0abf5 13. /build/src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: DB::ExceptionKeepingTransform::work() @ 0x0000000016c0a6fe 14. /build/src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x00000000169bd00f 15. /build/src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x00000000169b2105 16. /build/src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeSingleThread(unsigned long) @ 0x00000000169b23be 17. /build/src/Processors/Executors/PipelineExecutor.cpp:416: void std::__function::__policy_invoker::__call_impl[abi:se190107]>(std::__function::__policy_storage const*) @ 0x00000000169b2e3f 18. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc6653 19. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000000fccc4c3 20. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc3d92 21. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fcca080 22. ? @ 0x00007fbc6213eac3 23. ? @ 0x00007fbc621d0850 2025.07.28 11:58:45.953080 [ 7625 ] {} TCPHandler: Code: 242. DB::Exception: Table is in readonly mode due to shutdown: replica_path=/clickhouse/tables/01103_optimize_drop_race_zookeeper_test_15/concurrent_optimize_table/replicas/1. (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000a9b78ab 4. /build/src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:866: DB::ReplicatedMergeTreeSinkImpl::commitPart(std::shared_ptr const&, std::shared_ptr&, String const&, unsigned long)::'lambda1'()::operator()() const @ 0x000000001660eed7 5. /build/src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:1124: DB::ReplicatedMergeTreeSinkImpl::commitPart(std::shared_ptr const&, std::shared_ptr&, String const&, unsigned long)::'lambda2'()::operator()() const @ 0x000000001660d1f2 6. /build/src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:1157: void DB::ZooKeeperRetriesControl::retryLoop::commitPart(std::shared_ptr const&, std::shared_ptr&, String const&, unsigned long)::'lambda3'()&, void DB::ZooKeeperRetriesControl::retryLoop::commitPart(std::shared_ptr const&, std::shared_ptr&, String const&, unsigned long)::'lambda3'()>(DB::ReplicatedMergeTreeSinkImpl::commitPart(std::shared_ptr const&, std::shared_ptr&, String const&, unsigned long)::'lambda3'()&&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::commitPart(std::shared_ptr const&, std::shared_ptr&, String const&, unsigned long)::'lambda3'()&&, void DB::ZooKeeperRetriesControl::retryLoop::commitPart(std::shared_ptr const&, std::shared_ptr&, String const&, unsigned long)::'lambda3'()>(DB::ReplicatedMergeTreeSinkImpl::commitPart(std::shared_ptr const&, std::shared_ptr&, String const&, unsigned long)::'lambda3'()&&)::'lambda'()&&) @ 0x000000001660d07f 7. /build/src/Common/ZooKeeper/ZooKeeperRetries.h:52: DB::ReplicatedMergeTreeSinkImpl::commitPart(std::shared_ptr const&, std::shared_ptr&, String const&, unsigned long) @ 0x00000000165fd951 8. /build/src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:492: DB::ReplicatedMergeTreeSinkImpl::finishDelayedChunk(std::shared_ptr const&) @ 0x00000000165f277d 9. /build/src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:437: DB::ReplicatedMergeTreeSinkImpl::consume(DB::Chunk&) @ 0x00000000165fbd00 10. /build/src/Processors/Sinks/SinkToStorage.cpp:10: DB::SinkToStorage::onConsume(DB::Chunk) @ 0x0000000016cee093 11. /build/src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: void std::__function::__policy_invoker::__call_impl[abi:se190107]>(std::__function::__policy_storage const*) @ 0x0000000016c0ad89 12. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000016c0abf5 13. /build/src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: DB::ExceptionKeepingTransform::work() @ 0x0000000016c0a6fe 14. /build/src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x00000000169bd00f 15. /build/src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x00000000169b2105 16. /build/src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeSingleThread(unsigned long) @ 0x00000000169b23be 17. /build/src/Processors/Executors/PipelineExecutor.cpp:416: void std::__function::__policy_invoker::__call_impl[abi:se190107]>(std::__function::__policy_storage const*) @ 0x00000000169b2e3f 18. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc6653 19. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000000fccc4c3 20. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc3d92 21. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fcca080 22. ? @ 0x00007fbc6213eac3 23. ? @ 0x00007fbc621d0850 Job's origin stack trace: 0. /build/src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000000fc33b84 1. /build/src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000000fcc2ea7 2. /build/src/Common/ThreadPool.cpp:401: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fcc7f1c 3. /build/src/Common/ThreadPool.cpp:494: ThreadPoolImpl>::scheduleOrThrowOnError(std::function, Priority) @ 0x000000000fcc7a0e 4. /build/src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::spawnThreadsImpl() @ 0x00000000169b2c0c 5. /build/src/Processors/Executors/PipelineExecutor.cpp:394: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x00000000169b0ba7 6. /build/src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x00000000169b03f4 7. /build/src/Processors/Executors/CompletedPipelineExecutor.cpp:42: void std::__function::__policy_invoker::__call_impl[abi:se190107]::ThreadFromGlobalPoolImpl(DB::CompletedPipelineExecutor::execute()::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169af7e1 8. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc3d92 9. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fcca080 10. ? @ 0x00007fbc6213eac3 11. ? @ 0x00007fbc621d0850 Job's origin stack trace: 0. /build/src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000000fc33b84 1. /build/src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000000fcc2ea7 2. /build/src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fcc535c 3. /build/src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000000fcc584d 4. /build/src/Common/ThreadPool.h:279: DB::CompletedPipelineExecutor::execute() @ 0x00000000169af267 5. /build/src/Server/TCPHandler.cpp:707: DB::TCPHandler::runImpl() @ 0x00000000168e6b2e 6. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 7. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 8. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 9. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 10. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 11. ? @ 0x00007fbc6213eac3 12. ? @ 0x00007fbc621d0850 2025.07.28 11:58:46.009243 [ 17255 ] {31da0adb-c544-4fc6-a2a0-ccd7570f011b} executeQuery: Code: 242. DB::Exception: Table is in readonly mode due to shutdown: replica_path=/clickhouse/tables/01103_optimize_drop_race_zookeeper_test_15/concurrent_optimize_table/replicas/1. (TABLE_IS_READ_ONLY) (version 25.3.6.10636.altinitytest (altinity build)) (from [::1]:51440) (comment: 01103_optimize_drop_race_zookeeper.sh) (query 1, line 1) (in query: INSERT INTO concurrent_optimize_table SELECT rand(1), rand(2), 1 / rand(3), toString(rand(4)), [rand(5), rand(6)], rand(7) % 2 ? NULL : generateUUIDv4(), (rand(8), rand(9)) FROM numbers(10000)), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000a9b78ab 4. /build/src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:866: DB::ReplicatedMergeTreeSinkImpl::commitPart(std::shared_ptr const&, std::shared_ptr&, String const&, unsigned long)::'lambda1'()::operator()() const @ 0x000000001660eed7 5. /build/src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:1124: DB::ReplicatedMergeTreeSinkImpl::commitPart(std::shared_ptr const&, std::shared_ptr&, String const&, unsigned long)::'lambda2'()::operator()() const @ 0x000000001660d1f2 6. /build/src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:1157: void DB::ZooKeeperRetriesControl::retryLoop::commitPart(std::shared_ptr const&, std::shared_ptr&, String const&, unsigned long)::'lambda3'()&, void DB::ZooKeeperRetriesControl::retryLoop::commitPart(std::shared_ptr const&, std::shared_ptr&, String const&, unsigned long)::'lambda3'()>(DB::ReplicatedMergeTreeSinkImpl::commitPart(std::shared_ptr const&, std::shared_ptr&, String const&, unsigned long)::'lambda3'()&&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::commitPart(std::shared_ptr const&, std::shared_ptr&, String const&, unsigned long)::'lambda3'()&&, void DB::ZooKeeperRetriesControl::retryLoop::commitPart(std::shared_ptr const&, std::shared_ptr&, String const&, unsigned long)::'lambda3'()>(DB::ReplicatedMergeTreeSinkImpl::commitPart(std::shared_ptr const&, std::shared_ptr&, String const&, unsigned long)::'lambda3'()&&)::'lambda'()&&) @ 0x000000001660d07f 7. /build/src/Common/ZooKeeper/ZooKeeperRetries.h:52: DB::ReplicatedMergeTreeSinkImpl::commitPart(std::shared_ptr const&, std::shared_ptr&, String const&, unsigned long) @ 0x00000000165fd951 8. /build/src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:492: DB::ReplicatedMergeTreeSinkImpl::finishDelayedChunk(std::shared_ptr const&) @ 0x00000000165f277d 9. /build/src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:437: DB::ReplicatedMergeTreeSinkImpl::consume(DB::Chunk&) @ 0x00000000165fbd00 10. /build/src/Processors/Sinks/SinkToStorage.cpp:10: DB::SinkToStorage::onConsume(DB::Chunk) @ 0x0000000016cee093 11. /build/src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: void std::__function::__policy_invoker::__call_impl[abi:se190107]>(std::__function::__policy_storage const*) @ 0x0000000016c0ad89 12. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000016c0abf5 13. /build/src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: DB::ExceptionKeepingTransform::work() @ 0x0000000016c0a6fe 14. /build/src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x00000000169bd00f 15. /build/src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x00000000169b2105 16. /build/src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeSingleThread(unsigned long) @ 0x00000000169b23be 17. /build/src/Processors/Executors/PipelineExecutor.cpp:416: void std::__function::__policy_invoker::__call_impl[abi:se190107]>(std::__function::__policy_storage const*) @ 0x00000000169b2e3f 18. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc6653 19. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000000fccc4c3 20. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc3d92 21. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fcca080 22. ? @ 0x00007fbc6213eac3 23. ? @ 0x00007fbc621d0850 2025.07.28 11:58:46.022661 [ 4581 ] {5d7539ee-ffbd-47a3-aca9-81f73501ca3b} executeQuery: Code: 60. DB::Exception: Table test_15.concurrent_optimize_table does not exist. (UNKNOWN_TABLE) (version 25.3.6.10636.altinitytest (altinity build)) (from [::1]:51558) (comment: 01103_optimize_drop_race_zookeeper.sh) (query 1, line 1) (in query: OPTIMIZE TABLE concurrent_optimize_table FINAL), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000a06a8eb 4. /build/src/Databases/IDatabase.cpp:41: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x0000000013dd565f 5. /build/src/Interpreters/DatabaseCatalog.cpp:442: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x00000000144f0869 6. /build/src/Interpreters/DatabaseCatalog.cpp:976: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x00000000144f6c88 7. /build/src/Interpreters/InterpreterOptimizeQuery.cpp:40: DB::InterpreterOptimizeQuery::execute() @ 0x0000000014cd71de 8. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88dc9 9. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 10. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 11. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 12. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 13. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 14. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 15. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 16. ? @ 0x00007fbc6213eac3 17. ? @ 0x00007fbc621d0850 2025.07.28 11:58:46.019022 [ 17203 ] {c81c6715-b37f-42b9-a4ae-edc96e31c5ba} executeQuery: Code: 60. DB::Exception: Table test_15.concurrent_optimize_table does not exist. (UNKNOWN_TABLE) (version 25.3.6.10636.altinitytest (altinity build)) (from [::1]:51554) (comment: 01103_optimize_drop_race_zookeeper.sh) (query 1, line 1) (in query: OPTIMIZE TABLE concurrent_optimize_table FINAL), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000a06a8eb 4. /build/src/Databases/IDatabase.cpp:41: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x0000000013dd565f 5. /build/src/Interpreters/DatabaseCatalog.cpp:442: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x00000000144f0869 6. /build/src/Interpreters/DatabaseCatalog.cpp:976: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x00000000144f6c88 7. /build/src/Interpreters/InterpreterOptimizeQuery.cpp:40: DB::InterpreterOptimizeQuery::execute() @ 0x0000000014cd71de 8. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88dc9 9. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 10. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 11. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 12. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 13. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 14. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 15. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 16. ? @ 0x00007fbc6213eac3 17. ? @ 0x00007fbc621d0850 2025.07.28 11:58:46.061520 [ 17255 ] {} TCPHandler: Code: 242. DB::Exception: Table is in readonly mode due to shutdown: replica_path=/clickhouse/tables/01103_optimize_drop_race_zookeeper_test_15/concurrent_optimize_table/replicas/1. (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000a9b78ab 4. /build/src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:866: DB::ReplicatedMergeTreeSinkImpl::commitPart(std::shared_ptr const&, std::shared_ptr&, String const&, unsigned long)::'lambda1'()::operator()() const @ 0x000000001660eed7 5. /build/src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:1124: DB::ReplicatedMergeTreeSinkImpl::commitPart(std::shared_ptr const&, std::shared_ptr&, String const&, unsigned long)::'lambda2'()::operator()() const @ 0x000000001660d1f2 6. /build/src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:1157: void DB::ZooKeeperRetriesControl::retryLoop::commitPart(std::shared_ptr const&, std::shared_ptr&, String const&, unsigned long)::'lambda3'()&, void DB::ZooKeeperRetriesControl::retryLoop::commitPart(std::shared_ptr const&, std::shared_ptr&, String const&, unsigned long)::'lambda3'()>(DB::ReplicatedMergeTreeSinkImpl::commitPart(std::shared_ptr const&, std::shared_ptr&, String const&, unsigned long)::'lambda3'()&&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::commitPart(std::shared_ptr const&, std::shared_ptr&, String const&, unsigned long)::'lambda3'()&&, void DB::ZooKeeperRetriesControl::retryLoop::commitPart(std::shared_ptr const&, std::shared_ptr&, String const&, unsigned long)::'lambda3'()>(DB::ReplicatedMergeTreeSinkImpl::commitPart(std::shared_ptr const&, std::shared_ptr&, String const&, unsigned long)::'lambda3'()&&)::'lambda'()&&) @ 0x000000001660d07f 7. /build/src/Common/ZooKeeper/ZooKeeperRetries.h:52: DB::ReplicatedMergeTreeSinkImpl::commitPart(std::shared_ptr const&, std::shared_ptr&, String const&, unsigned long) @ 0x00000000165fd951 8. /build/src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:492: DB::ReplicatedMergeTreeSinkImpl::finishDelayedChunk(std::shared_ptr const&) @ 0x00000000165f277d 9. /build/src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:437: DB::ReplicatedMergeTreeSinkImpl::consume(DB::Chunk&) @ 0x00000000165fbd00 10. /build/src/Processors/Sinks/SinkToStorage.cpp:10: DB::SinkToStorage::onConsume(DB::Chunk) @ 0x0000000016cee093 11. /build/src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: void std::__function::__policy_invoker::__call_impl[abi:se190107]>(std::__function::__policy_storage const*) @ 0x0000000016c0ad89 12. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000016c0abf5 13. /build/src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: DB::ExceptionKeepingTransform::work() @ 0x0000000016c0a6fe 14. /build/src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x00000000169bd00f 15. /build/src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x00000000169b2105 16. /build/src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeSingleThread(unsigned long) @ 0x00000000169b23be 17. /build/src/Processors/Executors/PipelineExecutor.cpp:416: void std::__function::__policy_invoker::__call_impl[abi:se190107]>(std::__function::__policy_storage const*) @ 0x00000000169b2e3f 18. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc6653 19. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000000fccc4c3 20. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc3d92 21. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fcca080 22. ? @ 0x00007fbc6213eac3 23. ? @ 0x00007fbc621d0850 Job's origin stack trace: 0. /build/src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000000fc33b84 1. /build/src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000000fcc2ea7 2. /build/src/Common/ThreadPool.cpp:401: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fcc7f1c 3. /build/src/Common/ThreadPool.cpp:494: ThreadPoolImpl>::scheduleOrThrowOnError(std::function, Priority) @ 0x000000000fcc7a0e 4. /build/src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::spawnThreadsImpl() @ 0x00000000169b2c0c 5. /build/src/Processors/Executors/PipelineExecutor.cpp:394: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x00000000169b0ba7 6. /build/src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x00000000169b03f4 7. /build/src/Processors/Executors/CompletedPipelineExecutor.cpp:42: void std::__function::__policy_invoker::__call_impl[abi:se190107]::ThreadFromGlobalPoolImpl(DB::CompletedPipelineExecutor::execute()::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169af7e1 8. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc3d92 9. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fcca080 10. ? @ 0x00007fbc6213eac3 11. ? @ 0x00007fbc621d0850 Job's origin stack trace: 0. /build/src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000000fc33b84 1. /build/src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000000fcc2ea7 2. /build/src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fcc535c 3. /build/src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000000fcc584d 4. /build/src/Common/ThreadPool.h:279: DB::CompletedPipelineExecutor::execute() @ 0x00000000169af267 5. /build/src/Server/TCPHandler.cpp:707: DB::TCPHandler::runImpl() @ 0x00000000168e6b2e 6. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 7. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 8. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 9. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 10. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 11. ? @ 0x00007fbc6213eac3 12. ? @ 0x00007fbc621d0850 2025.07.28 11:58:46.065034 [ 17203 ] {} TCPHandler: Code: 60. DB::Exception: Table test_15.concurrent_optimize_table does not exist. (UNKNOWN_TABLE), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000a06a8eb 4. /build/src/Databases/IDatabase.cpp:41: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x0000000013dd565f 5. /build/src/Interpreters/DatabaseCatalog.cpp:442: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x00000000144f0869 6. /build/src/Interpreters/DatabaseCatalog.cpp:976: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x00000000144f6c88 7. /build/src/Interpreters/InterpreterOptimizeQuery.cpp:40: DB::InterpreterOptimizeQuery::execute() @ 0x0000000014cd71de 8. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88dc9 9. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 10. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 11. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 12. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 13. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 14. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 15. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 16. ? @ 0x00007fbc6213eac3 17. ? @ 0x00007fbc621d0850 2025.07.28 11:58:46.071107 [ 4581 ] {} TCPHandler: Code: 60. DB::Exception: Table test_15.concurrent_optimize_table does not exist. (UNKNOWN_TABLE), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000a06a8eb 4. /build/src/Databases/IDatabase.cpp:41: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x0000000013dd565f 5. /build/src/Interpreters/DatabaseCatalog.cpp:442: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x00000000144f0869 6. /build/src/Interpreters/DatabaseCatalog.cpp:976: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x00000000144f6c88 7. /build/src/Interpreters/InterpreterOptimizeQuery.cpp:40: DB::InterpreterOptimizeQuery::execute() @ 0x0000000014cd71de 8. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88dc9 9. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 10. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 11. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 12. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 13. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 14. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 15. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 16. ? @ 0x00007fbc6213eac3 17. ? @ 0x00007fbc621d0850 2025.07.28 11:58:46.096377 [ 17256 ] {0c7cbde9-6786-4dce-b5bf-acc2d9ff24d7} executeQuery: Code: 60. DB::Exception: Table test_15.concurrent_optimize_table does not exist. (UNKNOWN_TABLE) (version 25.3.6.10636.altinitytest (altinity build)) (from [::1]:51578) (comment: 01103_optimize_drop_race_zookeeper.sh) (query 1, line 1) (in query: INSERT INTO concurrent_optimize_table SELECT rand(1), rand(2), 1 / rand(3), toString(rand(4)), [rand(5), rand(6)], rand(7) % 2 ? NULL : generateUUIDv4(), (rand(8), rand(9)) FROM numbers(10000)), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000a06a8eb 4. /build/src/Databases/IDatabase.cpp:41: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x0000000013dd565f 5. /build/src/Interpreters/DatabaseCatalog.cpp:442: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x00000000144f0869 6. /build/src/Interpreters/DatabaseCatalog.cpp:976: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x00000000144f6c88 7. /build/src/Interpreters/InterpreterInsertQuery.cpp:169: DB::InterpreterInsertQuery::getTable(DB::ASTInsertQuery&) @ 0x000000001492bf04 8. /build/src/Interpreters/InterpreterInsertQuery.cpp:829: DB::InterpreterInsertQuery::execute() @ 0x0000000014933938 9. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88dc9 10. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 11. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 12. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 13. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 14. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 16. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 17. ? @ 0x00007fbc6213eac3 18. ? @ 0x00007fbc621d0850 2025.07.28 11:58:46.123431 [ 17256 ] {} TCPHandler: Code: 60. DB::Exception: Table test_15.concurrent_optimize_table does not exist. (UNKNOWN_TABLE), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000a06a8eb 4. /build/src/Databases/IDatabase.cpp:41: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x0000000013dd565f 5. /build/src/Interpreters/DatabaseCatalog.cpp:442: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x00000000144f0869 6. /build/src/Interpreters/DatabaseCatalog.cpp:976: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x00000000144f6c88 7. /build/src/Interpreters/InterpreterInsertQuery.cpp:169: DB::InterpreterInsertQuery::getTable(DB::ASTInsertQuery&) @ 0x000000001492bf04 8. /build/src/Interpreters/InterpreterInsertQuery.cpp:829: DB::InterpreterInsertQuery::execute() @ 0x0000000014933938 9. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88dc9 10. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 11. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 12. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 13. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 14. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 16. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 17. ? @ 0x00007fbc6213eac3 18. ? @ 0x00007fbc621d0850 2025.07.28 11:58:46.286759 [ 17252 ] {e8972c8d-9399-42ef-aa3c-f073b636e672} executeQuery: Code: 60. DB::Exception: Table test_15.concurrent_optimize_table does not exist. (UNKNOWN_TABLE) (version 25.3.6.10636.altinitytest (altinity build)) (from [::1]:51594) (comment: 01103_optimize_drop_race_zookeeper.sh) (query 1, line 1) (in query: OPTIMIZE TABLE concurrent_optimize_table FINAL), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000a06a8eb 4. /build/src/Databases/IDatabase.cpp:41: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x0000000013dd565f 5. /build/src/Interpreters/DatabaseCatalog.cpp:442: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x00000000144f0869 6. /build/src/Interpreters/DatabaseCatalog.cpp:976: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x00000000144f6c88 7. /build/src/Interpreters/InterpreterOptimizeQuery.cpp:40: DB::InterpreterOptimizeQuery::execute() @ 0x0000000014cd71de 8. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88dc9 9. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 10. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 11. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 12. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 13. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 14. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 15. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 16. ? @ 0x00007fbc6213eac3 17. ? @ 0x00007fbc621d0850 2025.07.28 11:58:46.304832 [ 17306 ] {fa55e777-2b51-4652-91d9-cf4f92643a77} executeQuery: Code: 60. DB::Exception: Table test_15.concurrent_optimize_table does not exist. (UNKNOWN_TABLE) (version 25.3.6.10636.altinitytest (altinity build)) (from [::1]:51618) (comment: 01103_optimize_drop_race_zookeeper.sh) (query 1, line 1) (in query: INSERT INTO concurrent_optimize_table SELECT rand(1), rand(2), 1 / rand(3), toString(rand(4)), [rand(5), rand(6)], rand(7) % 2 ? NULL : generateUUIDv4(), (rand(8), rand(9)) FROM numbers(10000)), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000a06a8eb 4. /build/src/Databases/IDatabase.cpp:41: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x0000000013dd565f 5. /build/src/Interpreters/DatabaseCatalog.cpp:442: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x00000000144f0869 6. /build/src/Interpreters/DatabaseCatalog.cpp:976: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x00000000144f6c88 7. /build/src/Interpreters/InterpreterInsertQuery.cpp:169: DB::InterpreterInsertQuery::getTable(DB::ASTInsertQuery&) @ 0x000000001492bf04 8. /build/src/Interpreters/InterpreterInsertQuery.cpp:829: DB::InterpreterInsertQuery::execute() @ 0x0000000014933938 9. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88dc9 10. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 11. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 12. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 13. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 14. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 16. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 17. ? @ 0x00007fbc6213eac3 18. ? @ 0x00007fbc621d0850 2025.07.28 11:58:46.311076 [ 17252 ] {} TCPHandler: Code: 60. DB::Exception: Table test_15.concurrent_optimize_table does not exist. (UNKNOWN_TABLE), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000a06a8eb 4. /build/src/Databases/IDatabase.cpp:41: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x0000000013dd565f 5. /build/src/Interpreters/DatabaseCatalog.cpp:442: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x00000000144f0869 6. /build/src/Interpreters/DatabaseCatalog.cpp:976: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x00000000144f6c88 7. /build/src/Interpreters/InterpreterOptimizeQuery.cpp:40: DB::InterpreterOptimizeQuery::execute() @ 0x0000000014cd71de 8. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88dc9 9. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 10. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 11. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 12. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 13. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 14. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 15. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 16. ? @ 0x00007fbc6213eac3 17. ? @ 0x00007fbc621d0850 2025.07.28 11:58:46.316398 [ 3287 ] {4f628fa1-388b-483b-b159-a8e0a4d5d91a} executeQuery: Code: 60. DB::Exception: Table test_15.concurrent_optimize_table does not exist. (UNKNOWN_TABLE) (version 25.3.6.10636.altinitytest (altinity build)) (from [::1]:51608) (comment: 01103_optimize_drop_race_zookeeper.sh) (query 1, line 1) (in query: INSERT INTO concurrent_optimize_table SELECT rand(1), rand(2), 1 / rand(3), toString(rand(4)), [rand(5), rand(6)], rand(7) % 2 ? NULL : generateUUIDv4(), (rand(8), rand(9)) FROM numbers(10000)), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000a06a8eb 4. /build/src/Databases/IDatabase.cpp:41: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x0000000013dd565f 5. /build/src/Interpreters/DatabaseCatalog.cpp:442: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x00000000144f0869 6. /build/src/Interpreters/DatabaseCatalog.cpp:976: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x00000000144f6c88 7. /build/src/Interpreters/InterpreterInsertQuery.cpp:169: DB::InterpreterInsertQuery::getTable(DB::ASTInsertQuery&) @ 0x000000001492bf04 8. /build/src/Interpreters/InterpreterInsertQuery.cpp:829: DB::InterpreterInsertQuery::execute() @ 0x0000000014933938 9. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88dc9 10. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 11. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 12. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 13. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 14. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 16. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 17. ? @ 0x00007fbc6213eac3 18. ? @ 0x00007fbc621d0850 2025.07.28 11:58:46.320513 [ 17306 ] {} TCPHandler: Code: 60. DB::Exception: Table test_15.concurrent_optimize_table does not exist. (UNKNOWN_TABLE), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000a06a8eb 4. /build/src/Databases/IDatabase.cpp:41: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x0000000013dd565f 5. /build/src/Interpreters/DatabaseCatalog.cpp:442: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x00000000144f0869 6. /build/src/Interpreters/DatabaseCatalog.cpp:976: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x00000000144f6c88 7. /build/src/Interpreters/InterpreterInsertQuery.cpp:169: DB::InterpreterInsertQuery::getTable(DB::ASTInsertQuery&) @ 0x000000001492bf04 8. /build/src/Interpreters/InterpreterInsertQuery.cpp:829: DB::InterpreterInsertQuery::execute() @ 0x0000000014933938 9. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88dc9 10. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 11. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 12. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 13. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 14. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 16. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 17. ? @ 0x00007fbc6213eac3 18. ? @ 0x00007fbc621d0850 2025.07.28 11:58:46.337509 [ 3287 ] {} TCPHandler: Code: 60. DB::Exception: Table test_15.concurrent_optimize_table does not exist. (UNKNOWN_TABLE), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000a06a8eb 4. /build/src/Databases/IDatabase.cpp:41: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x0000000013dd565f 5. /build/src/Interpreters/DatabaseCatalog.cpp:442: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x00000000144f0869 6. /build/src/Interpreters/DatabaseCatalog.cpp:976: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x00000000144f6c88 7. /build/src/Interpreters/InterpreterInsertQuery.cpp:169: DB::InterpreterInsertQuery::getTable(DB::ASTInsertQuery&) @ 0x000000001492bf04 8. /build/src/Interpreters/InterpreterInsertQuery.cpp:829: DB::InterpreterInsertQuery::execute() @ 0x0000000014933938 9. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88dc9 10. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 11. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 12. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 13. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 14. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 16. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 17. ? @ 0x00007fbc6213eac3 18. ? @ 0x00007fbc621d0850 2025.07.28 11:58:46.358540 [ 17203 ] {6a55ea9a-d42c-49b8-bff6-34f0695c0713} executeQuery: Code: 60. DB::Exception: Table test_15.concurrent_optimize_table does not exist. (UNKNOWN_TABLE) (version 25.3.6.10636.altinitytest (altinity build)) (from [::1]:51632) (comment: 01103_optimize_drop_race_zookeeper.sh) (query 1, line 1) (in query: INSERT INTO concurrent_optimize_table SELECT rand(1), rand(2), 1 / rand(3), toString(rand(4)), [rand(5), rand(6)], rand(7) % 2 ? NULL : generateUUIDv4(), (rand(8), rand(9)) FROM numbers(10000)), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000a06a8eb 4. /build/src/Databases/IDatabase.cpp:41: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x0000000013dd565f 5. /build/src/Interpreters/DatabaseCatalog.cpp:442: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x00000000144f0869 6. /build/src/Interpreters/DatabaseCatalog.cpp:976: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x00000000144f6c88 7. /build/src/Interpreters/InterpreterInsertQuery.cpp:169: DB::InterpreterInsertQuery::getTable(DB::ASTInsertQuery&) @ 0x000000001492bf04 8. /build/src/Interpreters/InterpreterInsertQuery.cpp:829: DB::InterpreterInsertQuery::execute() @ 0x0000000014933938 9. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88dc9 10. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 11. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 12. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 13. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 14. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 16. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 17. ? @ 0x00007fbc6213eac3 18. ? @ 0x00007fbc621d0850 2025.07.28 11:58:46.370094 [ 17203 ] {} TCPHandler: Code: 60. DB::Exception: Table test_15.concurrent_optimize_table does not exist. (UNKNOWN_TABLE), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000a06a8eb 4. /build/src/Databases/IDatabase.cpp:41: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x0000000013dd565f 5. /build/src/Interpreters/DatabaseCatalog.cpp:442: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x00000000144f0869 6. /build/src/Interpreters/DatabaseCatalog.cpp:976: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x00000000144f6c88 7. /build/src/Interpreters/InterpreterInsertQuery.cpp:169: DB::InterpreterInsertQuery::getTable(DB::ASTInsertQuery&) @ 0x000000001492bf04 8. /build/src/Interpreters/InterpreterInsertQuery.cpp:829: DB::InterpreterInsertQuery::execute() @ 0x0000000014933938 9. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88dc9 10. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 11. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 12. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 13. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 14. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 16. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 17. ? @ 0x00007fbc6213eac3 18. ? @ 0x00007fbc621d0850 2025.07.28 11:58:46.473417 [ 3972 ] {} test_13.rmt2 (7f9b740d-015c-470e-8cc6-8ba33be0dc63): auto DB::StorageReplicatedMergeTree::processQueueEntry(ReplicatedMergeTreeQueue::SelectedEntryPtr)::(anonymous class)::operator()(LogEntryPtr &) const: Code: 86. DB::HTTPException: Received error from remote server http://146b4357c08d:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Ftest%2F01165%2Ftest_13%2Frmt%2Freplicas%2F1&part=20250728_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.6.10636.altinitytest (altinity build)) '. (RECEIVED_ERROR_FROM_REMOTE_IO_SERVER), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.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 const&, int&&, String const&, unsigned long&&, String const&) @ 0x000000000feda8d9 4. /build/src/IO/HTTPCommon.cpp:104: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x000000000feda6e2 5. /build/src/IO/HTTPCommon.cpp:93: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x000000000feda537 6. /build/src/IO/ReadWriteBufferFromHTTP.cpp:277: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x000000001184a4c4 7. /build/src/IO/ReadWriteBufferFromHTTP.cpp:285: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x000000001184a615 8. /build/src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x000000001184ae59 9. /build/src/IO/ReadWriteBufferFromHTTP.cpp:472: void std::__function::__policy_invoker::__call_impl[abi:se190107]>(std::__function::__policy_storage const*) @ 0x000000001184cedd 10. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001184858b 11. /build/src/IO/ReadWriteBufferFromHTTP.cpp:465: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x000000001184bf0b 12. /build/src/IO/ReadBuffer.h:60: DB::ReadBuffer::next() @ 0x000000000a148c7b 13. /build/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) @ 0x0000000011849fb2 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]>&)>&, 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&) @ 0x0000000011841980 15. /build/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) @ 0x000000001621208e 16. /build/src/Storages/StorageReplicatedMergeTree.cpp:5228: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl[abi:se190107] const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000015f9a5fe 17. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000015ed8bfd 18. /build/src/Storages/StorageReplicatedMergeTree.cpp:2514: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x0000000015ec9aab 19. /build/src/Storages/StorageReplicatedMergeTree.cpp:2349: DB::StorageReplicatedMergeTree::executeLogEntry(DB::ReplicatedMergeTreeLogEntry&) @ 0x0000000015eba91b 20. /build/src/Storages/StorageReplicatedMergeTree.cpp:3876: bool std::__function::__policy_invoker&)>::__call_impl[abi:se190107])::$_1, bool (std::shared_ptr&)>>(std::__function::__policy_storage const*, std::shared_ptr&) @ 0x0000000015f9837e 21. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000165d6fc3 22. /build/src/Storages/StorageReplicatedMergeTree.cpp:3872: DB::StorageReplicatedMergeTree::processQueueEntry(std::shared_ptr) @ 0x0000000015efc18a 23. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001624c1b2 24. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000162f9c70 25. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x00000000162fa55a 26. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc6653 27. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000000fccc4c3 28. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc3d92 29. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fcca080 30. ? @ 0x00007fbc6213eac3 31. ? @ 0x00007fbc621d0850 (version 25.3.6.10636.altinitytest (altinity build)) 2025.07.28 11:58:46.492145 [ 5951 ] {7cbe8694-ef98-40e7-a506-e9009ed34659} test_15.concurrent_optimize_table (d38d1440-9c9c-45e1-af72-0be3b26dd5c5): Removing leftovers from table /clickhouse/tables/01103_optimize_drop_race_zookeeper_test_15/concurrent_optimize_table (this might take several minutes) 2025.07.28 11:58:46.503783 [ 5951 ] {7cbe8694-ef98-40e7-a506-e9009ed34659} test_15.concurrent_optimize_table (d38d1440-9c9c-45e1-af72-0be3b26dd5c5): The leftovers from table /clickhouse/tables/01103_optimize_drop_race_zookeeper_test_15/concurrent_optimize_table were removed by another replica 2025.07.28 11:58:46.512088 [ 4581 ] {01ba3110-f3f0-491b-8061-5f3c2070a343} executeQuery: Code: 60. DB::Exception: Table test_15.concurrent_optimize_table does not exist. (UNKNOWN_TABLE) (version 25.3.6.10636.altinitytest (altinity build)) (from [::1]:51634) (comment: 01103_optimize_drop_race_zookeeper.sh) (query 1, line 1) (in query: INSERT INTO concurrent_optimize_table SELECT rand(1), rand(2), 1 / rand(3), toString(rand(4)), [rand(5), rand(6)], rand(7) % 2 ? NULL : generateUUIDv4(), (rand(8), rand(9)) FROM numbers(10000)), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000a06a8eb 4. /build/src/Databases/IDatabase.cpp:41: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x0000000013dd565f 5. /build/src/Interpreters/DatabaseCatalog.cpp:442: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x00000000144f0869 6. /build/src/Interpreters/DatabaseCatalog.cpp:976: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x00000000144f6c88 7. /build/src/Interpreters/InterpreterInsertQuery.cpp:169: DB::InterpreterInsertQuery::getTable(DB::ASTInsertQuery&) @ 0x000000001492bf04 8. /build/src/Interpreters/InterpreterInsertQuery.cpp:829: DB::InterpreterInsertQuery::execute() @ 0x0000000014933938 9. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88dc9 10. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 11. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 12. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 13. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 14. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 16. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 17. ? @ 0x00007fbc6213eac3 18. ? @ 0x00007fbc621d0850 2025.07.28 11:58:46.527425 [ 4581 ] {} TCPHandler: Code: 60. DB::Exception: Table test_15.concurrent_optimize_table does not exist. (UNKNOWN_TABLE), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000a06a8eb 4. /build/src/Databases/IDatabase.cpp:41: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x0000000013dd565f 5. /build/src/Interpreters/DatabaseCatalog.cpp:442: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x00000000144f0869 6. /build/src/Interpreters/DatabaseCatalog.cpp:976: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x00000000144f6c88 7. /build/src/Interpreters/InterpreterInsertQuery.cpp:169: DB::InterpreterInsertQuery::getTable(DB::ASTInsertQuery&) @ 0x000000001492bf04 8. /build/src/Interpreters/InterpreterInsertQuery.cpp:829: DB::InterpreterInsertQuery::execute() @ 0x0000000014933938 9. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88dc9 10. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 11. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 12. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 13. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 14. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 16. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 17. ? @ 0x00007fbc6213eac3 18. ? @ 0x00007fbc621d0850 2025.07.28 11:58:46.644791 [ 17208 ] {c460e93a-b795-46f9-b6f1-ab7004fbebca} executeQuery: Code: 60. DB::Exception: Table test_15.concurrent_optimize_table does not exist. (UNKNOWN_TABLE) (version 25.3.6.10636.altinitytest (altinity build)) (from [::1]:51698) (comment: 01103_optimize_drop_race_zookeeper.sh) (query 1, line 1) (in query: OPTIMIZE TABLE concurrent_optimize_table FINAL), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000a06a8eb 4. /build/src/Databases/IDatabase.cpp:41: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x0000000013dd565f 5. /build/src/Interpreters/DatabaseCatalog.cpp:442: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x00000000144f0869 6. /build/src/Interpreters/DatabaseCatalog.cpp:976: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x00000000144f6c88 7. /build/src/Interpreters/InterpreterOptimizeQuery.cpp:40: DB::InterpreterOptimizeQuery::execute() @ 0x0000000014cd71de 8. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88dc9 9. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 10. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 11. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 12. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 13. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 14. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 15. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 16. ? @ 0x00007fbc6213eac3 17. ? @ 0x00007fbc621d0850 2025.07.28 11:58:46.650261 [ 17306 ] {cd46501c-9845-4e04-a09f-2a72fa452797} executeQuery: Code: 60. DB::Exception: Table test_15.concurrent_optimize_table does not exist. (UNKNOWN_TABLE) (version 25.3.6.10636.altinitytest (altinity build)) (from [::1]:51696) (comment: 01103_optimize_drop_race_zookeeper.sh) (query 1, line 1) (in query: INSERT INTO concurrent_optimize_table SELECT rand(1), rand(2), 1 / rand(3), toString(rand(4)), [rand(5), rand(6)], rand(7) % 2 ? NULL : generateUUIDv4(), (rand(8), rand(9)) FROM numbers(10000)), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000a06a8eb 4. /build/src/Databases/IDatabase.cpp:41: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x0000000013dd565f 5. /build/src/Interpreters/DatabaseCatalog.cpp:442: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x00000000144f0869 6. /build/src/Interpreters/DatabaseCatalog.cpp:976: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x00000000144f6c88 7. /build/src/Interpreters/InterpreterInsertQuery.cpp:169: DB::InterpreterInsertQuery::getTable(DB::ASTInsertQuery&) @ 0x000000001492bf04 8. /build/src/Interpreters/InterpreterInsertQuery.cpp:829: DB::InterpreterInsertQuery::execute() @ 0x0000000014933938 9. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88dc9 10. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 11. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 12. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 13. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 14. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 16. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 17. ? @ 0x00007fbc6213eac3 18. ? @ 0x00007fbc621d0850 2025.07.28 11:58:46.653581 [ 5951 ] {7cbe8694-ef98-40e7-a506-e9009ed34659} test_15.concurrent_optimize_table (d38d1440-9c9c-45e1-af72-0be3b26dd5c5): Removing leftovers from table /clickhouse/tables/01103_optimize_drop_race_zookeeper_test_15/concurrent_optimize_table (this might take several minutes) 2025.07.28 11:58:46.666638 [ 5951 ] {7cbe8694-ef98-40e7-a506-e9009ed34659} test_15.concurrent_optimize_table (d38d1440-9c9c-45e1-af72-0be3b26dd5c5): The leftovers from table /clickhouse/tables/01103_optimize_drop_race_zookeeper_test_15/concurrent_optimize_table were removed by another replica 2025.07.28 11:58:46.692455 [ 17208 ] {} TCPHandler: Code: 60. DB::Exception: Table test_15.concurrent_optimize_table does not exist. (UNKNOWN_TABLE), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000a06a8eb 4. /build/src/Databases/IDatabase.cpp:41: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x0000000013dd565f 5. /build/src/Interpreters/DatabaseCatalog.cpp:442: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x00000000144f0869 6. /build/src/Interpreters/DatabaseCatalog.cpp:976: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x00000000144f6c88 7. /build/src/Interpreters/InterpreterOptimizeQuery.cpp:40: DB::InterpreterOptimizeQuery::execute() @ 0x0000000014cd71de 8. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88dc9 9. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 10. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 11. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 12. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 13. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 14. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 15. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 16. ? @ 0x00007fbc6213eac3 17. ? @ 0x00007fbc621d0850 2025.07.28 11:58:46.724816 [ 17306 ] {} TCPHandler: Code: 60. DB::Exception: Table test_15.concurrent_optimize_table does not exist. (UNKNOWN_TABLE), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000a06a8eb 4. /build/src/Databases/IDatabase.cpp:41: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x0000000013dd565f 5. /build/src/Interpreters/DatabaseCatalog.cpp:442: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x00000000144f0869 6. /build/src/Interpreters/DatabaseCatalog.cpp:976: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x00000000144f6c88 7. /build/src/Interpreters/InterpreterInsertQuery.cpp:169: DB::InterpreterInsertQuery::getTable(DB::ASTInsertQuery&) @ 0x000000001492bf04 8. /build/src/Interpreters/InterpreterInsertQuery.cpp:829: DB::InterpreterInsertQuery::execute() @ 0x0000000014933938 9. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88dc9 10. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 11. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 12. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 13. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 14. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 16. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 17. ? @ 0x00007fbc6213eac3 18. ? @ 0x00007fbc621d0850 2025.07.28 11:58:46.743293 [ 17557 ] {1d1d4192-662c-463e-ad63-fe3dc13ea303} executeQuery: Code: 60. DB::Exception: Table test_15.concurrent_optimize_table does not exist. (UNKNOWN_TABLE) (version 25.3.6.10636.altinitytest (altinity build)) (from [::1]:51700) (comment: 01103_optimize_drop_race_zookeeper.sh) (query 1, line 1) (in query: OPTIMIZE TABLE concurrent_optimize_table FINAL), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000a06a8eb 4. /build/src/Databases/IDatabase.cpp:41: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x0000000013dd565f 5. /build/src/Interpreters/DatabaseCatalog.cpp:442: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x00000000144f0869 6. /build/src/Interpreters/DatabaseCatalog.cpp:976: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x00000000144f6c88 7. /build/src/Interpreters/InterpreterOptimizeQuery.cpp:40: DB::InterpreterOptimizeQuery::execute() @ 0x0000000014cd71de 8. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88dc9 9. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 10. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 11. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 12. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 13. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 14. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 15. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 16. ? @ 0x00007fbc6213eac3 17. ? @ 0x00007fbc621d0850 2025.07.28 11:58:46.743562 [ 3287 ] {59bdcc3c-93e2-487d-85d5-280f37825f12} executeQuery: Code: 60. DB::Exception: Table test_15.concurrent_optimize_table does not exist. (UNKNOWN_TABLE) (version 25.3.6.10636.altinitytest (altinity build)) (from [::1]:51688) (comment: 01103_optimize_drop_race_zookeeper.sh) (query 1, line 1) (in query: INSERT INTO concurrent_optimize_table SELECT rand(1), rand(2), 1 / rand(3), toString(rand(4)), [rand(5), rand(6)], rand(7) % 2 ? NULL : generateUUIDv4(), (rand(8), rand(9)) FROM numbers(10000)), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000a06a8eb 4. /build/src/Databases/IDatabase.cpp:41: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x0000000013dd565f 5. /build/src/Interpreters/DatabaseCatalog.cpp:442: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x00000000144f0869 6. /build/src/Interpreters/DatabaseCatalog.cpp:976: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x00000000144f6c88 7. /build/src/Interpreters/InterpreterInsertQuery.cpp:169: DB::InterpreterInsertQuery::getTable(DB::ASTInsertQuery&) @ 0x000000001492bf04 8. /build/src/Interpreters/InterpreterInsertQuery.cpp:829: DB::InterpreterInsertQuery::execute() @ 0x0000000014933938 9. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88dc9 10. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 11. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 12. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 13. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 14. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 16. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 17. ? @ 0x00007fbc6213eac3 18. ? @ 0x00007fbc621d0850 2025.07.28 11:58:46.755941 [ 17557 ] {} TCPHandler: Code: 60. DB::Exception: Table test_15.concurrent_optimize_table does not exist. (UNKNOWN_TABLE), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000a06a8eb 4. /build/src/Databases/IDatabase.cpp:41: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x0000000013dd565f 5. /build/src/Interpreters/DatabaseCatalog.cpp:442: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x00000000144f0869 6. /build/src/Interpreters/DatabaseCatalog.cpp:976: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x00000000144f6c88 7. /build/src/Interpreters/InterpreterOptimizeQuery.cpp:40: DB::InterpreterOptimizeQuery::execute() @ 0x0000000014cd71de 8. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88dc9 9. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 10. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 11. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 12. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 13. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 14. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 15. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 16. ? @ 0x00007fbc6213eac3 17. ? @ 0x00007fbc621d0850 2025.07.28 11:58:46.777346 [ 3287 ] {} TCPHandler: Code: 60. DB::Exception: Table test_15.concurrent_optimize_table does not exist. (UNKNOWN_TABLE), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000a06a8eb 4. /build/src/Databases/IDatabase.cpp:41: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x0000000013dd565f 5. /build/src/Interpreters/DatabaseCatalog.cpp:442: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x00000000144f0869 6. /build/src/Interpreters/DatabaseCatalog.cpp:976: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x00000000144f6c88 7. /build/src/Interpreters/InterpreterInsertQuery.cpp:169: DB::InterpreterInsertQuery::getTable(DB::ASTInsertQuery&) @ 0x000000001492bf04 8. /build/src/Interpreters/InterpreterInsertQuery.cpp:829: DB::InterpreterInsertQuery::execute() @ 0x0000000014933938 9. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88dc9 10. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 11. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 12. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 13. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 14. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 16. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 17. ? @ 0x00007fbc6213eac3 18. ? @ 0x00007fbc621d0850 2025.07.28 11:58:46.798543 [ 5951 ] {7cbe8694-ef98-40e7-a506-e9009ed34659} test_15.concurrent_optimize_table (d38d1440-9c9c-45e1-af72-0be3b26dd5c5): Removing leftovers from table /clickhouse/tables/01103_optimize_drop_race_zookeeper_test_15/concurrent_optimize_table (this might take several minutes) 2025.07.28 11:58:46.815651 [ 3283 ] {e8f3bdb2-092f-42a8-85a2-103fbce6f8a6} executeQuery: Code: 60. DB::Exception: Table test_15.concurrent_optimize_table does not exist. (UNKNOWN_TABLE) (version 25.3.6.10636.altinitytest (altinity build)) (from [::1]:51710) (comment: 01103_optimize_drop_race_zookeeper.sh) (query 1, line 1) (in query: INSERT INTO concurrent_optimize_table SELECT rand(1), rand(2), 1 / rand(3), toString(rand(4)), [rand(5), rand(6)], rand(7) % 2 ? NULL : generateUUIDv4(), (rand(8), rand(9)) FROM numbers(10000)), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000a06a8eb 4. /build/src/Databases/IDatabase.cpp:41: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x0000000013dd565f 5. /build/src/Interpreters/DatabaseCatalog.cpp:442: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x00000000144f0869 6. /build/src/Interpreters/DatabaseCatalog.cpp:976: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x00000000144f6c88 7. /build/src/Interpreters/InterpreterInsertQuery.cpp:169: DB::InterpreterInsertQuery::getTable(DB::ASTInsertQuery&) @ 0x000000001492bf04 8. /build/src/Interpreters/InterpreterInsertQuery.cpp:829: DB::InterpreterInsertQuery::execute() @ 0x0000000014933938 9. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88dc9 10. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 11. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 12. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 13. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 14. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 16. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 17. ? @ 0x00007fbc6213eac3 18. ? @ 0x00007fbc621d0850 2025.07.28 11:58:46.832319 [ 5951 ] {7cbe8694-ef98-40e7-a506-e9009ed34659} test_15.concurrent_optimize_table (d38d1440-9c9c-45e1-af72-0be3b26dd5c5): The leftovers from table /clickhouse/tables/01103_optimize_drop_race_zookeeper_test_15/concurrent_optimize_table were removed by another replica 2025.07.28 11:58:46.870756 [ 3283 ] {} TCPHandler: Code: 60. DB::Exception: Table test_15.concurrent_optimize_table does not exist. (UNKNOWN_TABLE), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000a06a8eb 4. /build/src/Databases/IDatabase.cpp:41: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x0000000013dd565f 5. /build/src/Interpreters/DatabaseCatalog.cpp:442: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x00000000144f0869 6. /build/src/Interpreters/DatabaseCatalog.cpp:976: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x00000000144f6c88 7. /build/src/Interpreters/InterpreterInsertQuery.cpp:169: DB::InterpreterInsertQuery::getTable(DB::ASTInsertQuery&) @ 0x000000001492bf04 8. /build/src/Interpreters/InterpreterInsertQuery.cpp:829: DB::InterpreterInsertQuery::execute() @ 0x0000000014933938 9. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88dc9 10. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 11. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 12. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 13. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 14. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 16. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 17. ? @ 0x00007fbc6213eac3 18. ? @ 0x00007fbc621d0850 2025.07.28 11:58:46.886836 [ 5879 ] {cc3e9d42-cca4-4926-8c53-c3a066086c3e} executeQuery: Code: 60. DB::Exception: Table test_15.concurrent_optimize_table does not exist. (UNKNOWN_TABLE) (version 25.3.6.10636.altinitytest (altinity build)) (from [::1]:51714) (comment: 01103_optimize_drop_race_zookeeper.sh) (query 1, line 1) (in query: OPTIMIZE TABLE concurrent_optimize_table FINAL), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000a06a8eb 4. /build/src/Databases/IDatabase.cpp:41: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x0000000013dd565f 5. /build/src/Interpreters/DatabaseCatalog.cpp:442: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x00000000144f0869 6. /build/src/Interpreters/DatabaseCatalog.cpp:976: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x00000000144f6c88 7. /build/src/Interpreters/InterpreterOptimizeQuery.cpp:40: DB::InterpreterOptimizeQuery::execute() @ 0x0000000014cd71de 8. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88dc9 9. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 10. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 11. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 12. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 13. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 14. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 15. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 16. ? @ 0x00007fbc6213eac3 17. ? @ 0x00007fbc621d0850 2025.07.28 11:58:46.906444 [ 5879 ] {} TCPHandler: Code: 60. DB::Exception: Table test_15.concurrent_optimize_table does not exist. (UNKNOWN_TABLE), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000a06a8eb 4. /build/src/Databases/IDatabase.cpp:41: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x0000000013dd565f 5. /build/src/Interpreters/DatabaseCatalog.cpp:442: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x00000000144f0869 6. /build/src/Interpreters/DatabaseCatalog.cpp:976: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x00000000144f6c88 7. /build/src/Interpreters/InterpreterOptimizeQuery.cpp:40: DB::InterpreterOptimizeQuery::execute() @ 0x0000000014cd71de 8. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88dc9 9. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 10. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 11. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 12. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 13. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 14. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 15. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 16. ? @ 0x00007fbc6213eac3 17. ? @ 0x00007fbc621d0850 2025.07.28 11:58:46.907737 [ 17611 ] {7bffe1e1-366b-4735-9839-a0e14ddc9f05} executeQuery: Code: 60. DB::Exception: Table test_15.concurrent_optimize_table does not exist. (UNKNOWN_TABLE) (version 25.3.6.10636.altinitytest (altinity build)) (from [::1]:51728) (comment: 01103_optimize_drop_race_zookeeper.sh) (query 1, line 1) (in query: OPTIMIZE TABLE concurrent_optimize_table FINAL), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000a06a8eb 4. /build/src/Databases/IDatabase.cpp:41: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x0000000013dd565f 5. /build/src/Interpreters/DatabaseCatalog.cpp:442: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x00000000144f0869 6. /build/src/Interpreters/DatabaseCatalog.cpp:976: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x00000000144f6c88 7. /build/src/Interpreters/InterpreterOptimizeQuery.cpp:40: DB::InterpreterOptimizeQuery::execute() @ 0x0000000014cd71de 8. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88dc9 9. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 10. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 11. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 12. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 13. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 14. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 15. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 16. ? @ 0x00007fbc6213eac3 17. ? @ 0x00007fbc621d0850 2025.07.28 11:58:46.911771 [ 4581 ] {d3283d43-0e5e-4bfa-98ef-611334af1eb3} executeQuery: Code: 60. DB::Exception: Table test_15.concurrent_optimize_table does not exist. (UNKNOWN_TABLE) (version 25.3.6.10636.altinitytest (altinity build)) (from [::1]:51712) (comment: 01103_optimize_drop_race_zookeeper.sh) (query 1, line 1) (in query: INSERT INTO concurrent_optimize_table SELECT rand(1), rand(2), 1 / rand(3), toString(rand(4)), [rand(5), rand(6)], rand(7) % 2 ? NULL : generateUUIDv4(), (rand(8), rand(9)) FROM numbers(10000)), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000a06a8eb 4. /build/src/Databases/IDatabase.cpp:41: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x0000000013dd565f 5. /build/src/Interpreters/DatabaseCatalog.cpp:442: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x00000000144f0869 6. /build/src/Interpreters/DatabaseCatalog.cpp:976: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x00000000144f6c88 7. /build/src/Interpreters/InterpreterInsertQuery.cpp:169: DB::InterpreterInsertQuery::getTable(DB::ASTInsertQuery&) @ 0x000000001492bf04 8. /build/src/Interpreters/InterpreterInsertQuery.cpp:829: DB::InterpreterInsertQuery::execute() @ 0x0000000014933938 9. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88dc9 10. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 11. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 12. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 13. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 14. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 16. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 17. ? @ 0x00007fbc6213eac3 18. ? @ 0x00007fbc621d0850 2025.07.28 11:58:46.931773 [ 17611 ] {} TCPHandler: Code: 60. DB::Exception: Table test_15.concurrent_optimize_table does not exist. (UNKNOWN_TABLE), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000a06a8eb 4. /build/src/Databases/IDatabase.cpp:41: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x0000000013dd565f 5. /build/src/Interpreters/DatabaseCatalog.cpp:442: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x00000000144f0869 6. /build/src/Interpreters/DatabaseCatalog.cpp:976: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x00000000144f6c88 7. /build/src/Interpreters/InterpreterOptimizeQuery.cpp:40: DB::InterpreterOptimizeQuery::execute() @ 0x0000000014cd71de 8. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88dc9 9. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 10. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 11. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 12. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 13. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 14. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 15. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 16. ? @ 0x00007fbc6213eac3 17. ? @ 0x00007fbc621d0850 2025.07.28 11:58:46.941856 [ 4581 ] {} TCPHandler: Code: 60. DB::Exception: Table test_15.concurrent_optimize_table does not exist. (UNKNOWN_TABLE), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000a06a8eb 4. /build/src/Databases/IDatabase.cpp:41: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x0000000013dd565f 5. /build/src/Interpreters/DatabaseCatalog.cpp:442: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x00000000144f0869 6. /build/src/Interpreters/DatabaseCatalog.cpp:976: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x00000000144f6c88 7. /build/src/Interpreters/InterpreterInsertQuery.cpp:169: DB::InterpreterInsertQuery::getTable(DB::ASTInsertQuery&) @ 0x000000001492bf04 8. /build/src/Interpreters/InterpreterInsertQuery.cpp:829: DB::InterpreterInsertQuery::execute() @ 0x0000000014933938 9. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88dc9 10. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 11. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 12. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 13. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 14. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 16. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 17. ? @ 0x00007fbc6213eac3 18. ? @ 0x00007fbc621d0850 2025.07.28 11:58:47.003218 [ 3965 ] {} test_13.rmt2 (7f9b740d-015c-470e-8cc6-8ba33be0dc63): auto DB::StorageReplicatedMergeTree::processQueueEntry(ReplicatedMergeTreeQueue::SelectedEntryPtr)::(anonymous class)::operator()(LogEntryPtr &) const: Code: 86. DB::HTTPException: Received error from remote server http://146b4357c08d:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Ftest%2F01165%2Ftest_13%2Frmt%2Freplicas%2F1&part=20250728_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.6.10636.altinitytest (altinity build)) '. (RECEIVED_ERROR_FROM_REMOTE_IO_SERVER), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.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 const&, int&&, String const&, unsigned long&&, String const&) @ 0x000000000feda8d9 4. /build/src/IO/HTTPCommon.cpp:104: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x000000000feda6e2 5. /build/src/IO/HTTPCommon.cpp:93: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x000000000feda537 6. /build/src/IO/ReadWriteBufferFromHTTP.cpp:277: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x000000001184a4c4 7. /build/src/IO/ReadWriteBufferFromHTTP.cpp:285: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x000000001184a615 8. /build/src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x000000001184ae59 9. /build/src/IO/ReadWriteBufferFromHTTP.cpp:472: void std::__function::__policy_invoker::__call_impl[abi:se190107]>(std::__function::__policy_storage const*) @ 0x000000001184cedd 10. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001184858b 11. /build/src/IO/ReadWriteBufferFromHTTP.cpp:465: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x000000001184bf0b 12. /build/src/IO/ReadBuffer.h:60: DB::ReadBuffer::next() @ 0x000000000a148c7b 13. /build/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) @ 0x0000000011849fb2 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]>&)>&, 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&) @ 0x0000000011841980 15. /build/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) @ 0x000000001621208e 16. /build/src/Storages/StorageReplicatedMergeTree.cpp:5228: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl[abi:se190107] const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000015f9a5fe 17. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000015ed8bfd 18. /build/src/Storages/StorageReplicatedMergeTree.cpp:2514: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x0000000015ec9aab 19. /build/src/Storages/StorageReplicatedMergeTree.cpp:2349: DB::StorageReplicatedMergeTree::executeLogEntry(DB::ReplicatedMergeTreeLogEntry&) @ 0x0000000015eba91b 20. /build/src/Storages/StorageReplicatedMergeTree.cpp:3876: bool std::__function::__policy_invoker&)>::__call_impl[abi:se190107])::$_1, bool (std::shared_ptr&)>>(std::__function::__policy_storage const*, std::shared_ptr&) @ 0x0000000015f9837e 21. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000165d6fc3 22. /build/src/Storages/StorageReplicatedMergeTree.cpp:3872: DB::StorageReplicatedMergeTree::processQueueEntry(std::shared_ptr) @ 0x0000000015efc18a 23. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001624c1b2 24. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000162f9c70 25. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x00000000162fa55a 26. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc6653 27. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000000fccc4c3 28. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc3d92 29. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fcca080 30. ? @ 0x00007fbc6213eac3 31. ? @ 0x00007fbc621d0850 (version 25.3.6.10636.altinitytest (altinity build)) 2025.07.28 11:58:47.019954 [ 17252 ] {0239757b-ccf2-41eb-af3e-5dde217228f1} executeQuery: Code: 60. DB::Exception: Table test_15.concurrent_optimize_table does not exist. (UNKNOWN_TABLE) (version 25.3.6.10636.altinitytest (altinity build)) (from [::1]:51742) (comment: 01103_optimize_drop_race_zookeeper.sh) (query 1, line 1) (in query: INSERT INTO concurrent_optimize_table SELECT rand(1), rand(2), 1 / rand(3), toString(rand(4)), [rand(5), rand(6)], rand(7) % 2 ? NULL : generateUUIDv4(), (rand(8), rand(9)) FROM numbers(10000)), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000a06a8eb 4. /build/src/Databases/IDatabase.cpp:41: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x0000000013dd565f 5. /build/src/Interpreters/DatabaseCatalog.cpp:442: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x00000000144f0869 6. /build/src/Interpreters/DatabaseCatalog.cpp:976: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x00000000144f6c88 7. /build/src/Interpreters/InterpreterInsertQuery.cpp:169: DB::InterpreterInsertQuery::getTable(DB::ASTInsertQuery&) @ 0x000000001492bf04 8. /build/src/Interpreters/InterpreterInsertQuery.cpp:829: DB::InterpreterInsertQuery::execute() @ 0x0000000014933938 9. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88dc9 10. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 11. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 12. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 13. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 14. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 16. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 17. ? @ 0x00007fbc6213eac3 18. ? @ 0x00007fbc621d0850 2025.07.28 11:58:47.049112 [ 17252 ] {} TCPHandler: Code: 60. DB::Exception: Table test_15.concurrent_optimize_table does not exist. (UNKNOWN_TABLE), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000a06a8eb 4. /build/src/Databases/IDatabase.cpp:41: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x0000000013dd565f 5. /build/src/Interpreters/DatabaseCatalog.cpp:442: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x00000000144f0869 6. /build/src/Interpreters/DatabaseCatalog.cpp:976: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x00000000144f6c88 7. /build/src/Interpreters/InterpreterInsertQuery.cpp:169: DB::InterpreterInsertQuery::getTable(DB::ASTInsertQuery&) @ 0x000000001492bf04 8. /build/src/Interpreters/InterpreterInsertQuery.cpp:829: DB::InterpreterInsertQuery::execute() @ 0x0000000014933938 9. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88dc9 10. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 11. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 12. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 13. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 14. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 16. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 17. ? @ 0x00007fbc6213eac3 18. ? @ 0x00007fbc621d0850 2025.07.28 11:58:47.144133 [ 3287 ] {4e02e027-616e-4dcc-a8b8-b0e02b75e9e8} executeQuery: Code: 60. DB::Exception: Table test_15.concurrent_optimize_table does not exist. (UNKNOWN_TABLE) (version 25.3.6.10636.altinitytest (altinity build)) (from [::1]:51754) (comment: 01103_optimize_drop_race_zookeeper.sh) (query 1, line 1) (in query: INSERT INTO concurrent_optimize_table SELECT rand(1), rand(2), 1 / rand(3), toString(rand(4)), [rand(5), rand(6)], rand(7) % 2 ? NULL : generateUUIDv4(), (rand(8), rand(9)) FROM numbers(10000)), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000a06a8eb 4. /build/src/Databases/IDatabase.cpp:41: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x0000000013dd565f 5. /build/src/Interpreters/DatabaseCatalog.cpp:442: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x00000000144f0869 6. /build/src/Interpreters/DatabaseCatalog.cpp:976: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x00000000144f6c88 7. /build/src/Interpreters/InterpreterInsertQuery.cpp:169: DB::InterpreterInsertQuery::getTable(DB::ASTInsertQuery&) @ 0x000000001492bf04 8. /build/src/Interpreters/InterpreterInsertQuery.cpp:829: DB::InterpreterInsertQuery::execute() @ 0x0000000014933938 9. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88dc9 10. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 11. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 12. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 13. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 14. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 16. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 17. ? @ 0x00007fbc6213eac3 18. ? @ 0x00007fbc621d0850 2025.07.28 11:58:47.145956 [ 17306 ] {bdadb560-73f0-468a-9ccf-4c16d28ebb17} executeQuery: Code: 60. DB::Exception: Table test_15.concurrent_optimize_table does not exist. (UNKNOWN_TABLE) (version 25.3.6.10636.altinitytest (altinity build)) (from [::1]:51766) (comment: 01103_optimize_drop_race_zookeeper.sh) (query 1, line 1) (in query: INSERT INTO concurrent_optimize_table SELECT rand(1), rand(2), 1 / rand(3), toString(rand(4)), [rand(5), rand(6)], rand(7) % 2 ? NULL : generateUUIDv4(), (rand(8), rand(9)) FROM numbers(10000)), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000a06a8eb 4. /build/src/Databases/IDatabase.cpp:41: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x0000000013dd565f 5. /build/src/Interpreters/DatabaseCatalog.cpp:442: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x00000000144f0869 6. /build/src/Interpreters/DatabaseCatalog.cpp:976: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x00000000144f6c88 7. /build/src/Interpreters/InterpreterInsertQuery.cpp:169: DB::InterpreterInsertQuery::getTable(DB::ASTInsertQuery&) @ 0x000000001492bf04 8. /build/src/Interpreters/InterpreterInsertQuery.cpp:829: DB::InterpreterInsertQuery::execute() @ 0x0000000014933938 9. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88dc9 10. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 11. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 12. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 13. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 14. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 16. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 17. ? @ 0x00007fbc6213eac3 18. ? @ 0x00007fbc621d0850 2025.07.28 11:58:47.161180 [ 3287 ] {} TCPHandler: Code: 60. DB::Exception: Table test_15.concurrent_optimize_table does not exist. (UNKNOWN_TABLE), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000a06a8eb 4. /build/src/Databases/IDatabase.cpp:41: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x0000000013dd565f 5. /build/src/Interpreters/DatabaseCatalog.cpp:442: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x00000000144f0869 6. /build/src/Interpreters/DatabaseCatalog.cpp:976: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x00000000144f6c88 7. /build/src/Interpreters/InterpreterInsertQuery.cpp:169: DB::InterpreterInsertQuery::getTable(DB::ASTInsertQuery&) @ 0x000000001492bf04 8. /build/src/Interpreters/InterpreterInsertQuery.cpp:829: DB::InterpreterInsertQuery::execute() @ 0x0000000014933938 9. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88dc9 10. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 11. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 12. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 13. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 14. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 16. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 17. ? @ 0x00007fbc6213eac3 18. ? @ 0x00007fbc621d0850 2025.07.28 11:58:47.177133 [ 17306 ] {} TCPHandler: Code: 60. DB::Exception: Table test_15.concurrent_optimize_table does not exist. (UNKNOWN_TABLE), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000a06a8eb 4. /build/src/Databases/IDatabase.cpp:41: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x0000000013dd565f 5. /build/src/Interpreters/DatabaseCatalog.cpp:442: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x00000000144f0869 6. /build/src/Interpreters/DatabaseCatalog.cpp:976: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x00000000144f6c88 7. /build/src/Interpreters/InterpreterInsertQuery.cpp:169: DB::InterpreterInsertQuery::getTable(DB::ASTInsertQuery&) @ 0x000000001492bf04 8. /build/src/Interpreters/InterpreterInsertQuery.cpp:829: DB::InterpreterInsertQuery::execute() @ 0x0000000014933938 9. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88dc9 10. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 11. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 12. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 13. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 14. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 16. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 17. ? @ 0x00007fbc6213eac3 18. ? @ 0x00007fbc621d0850 2025.07.28 11:58:47.194484 [ 4581 ] {a24e929c-c987-4228-a390-9cd854aca627} executeQuery: Code: 60. DB::Exception: Table test_15.concurrent_optimize_table does not exist. (UNKNOWN_TABLE) (version 25.3.6.10636.altinitytest (altinity build)) (from [::1]:51780) (comment: 01103_optimize_drop_race_zookeeper.sh) (query 1, line 1) (in query: OPTIMIZE TABLE concurrent_optimize_table FINAL), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000a06a8eb 4. /build/src/Databases/IDatabase.cpp:41: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x0000000013dd565f 5. /build/src/Interpreters/DatabaseCatalog.cpp:442: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x00000000144f0869 6. /build/src/Interpreters/DatabaseCatalog.cpp:976: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x00000000144f6c88 7. /build/src/Interpreters/InterpreterOptimizeQuery.cpp:40: DB::InterpreterOptimizeQuery::execute() @ 0x0000000014cd71de 8. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88dc9 9. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 10. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 11. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 12. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 13. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 14. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 15. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 16. ? @ 0x00007fbc6213eac3 17. ? @ 0x00007fbc621d0850 2025.07.28 11:58:47.204162 [ 4581 ] {} TCPHandler: Code: 60. DB::Exception: Table test_15.concurrent_optimize_table does not exist. (UNKNOWN_TABLE), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000a06a8eb 4. /build/src/Databases/IDatabase.cpp:41: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x0000000013dd565f 5. /build/src/Interpreters/DatabaseCatalog.cpp:442: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x00000000144f0869 6. /build/src/Interpreters/DatabaseCatalog.cpp:976: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x00000000144f6c88 7. /build/src/Interpreters/InterpreterOptimizeQuery.cpp:40: DB::InterpreterOptimizeQuery::execute() @ 0x0000000014cd71de 8. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88dc9 9. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 10. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 11. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 12. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 13. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 14. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 15. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 16. ? @ 0x00007fbc6213eac3 17. ? @ 0x00007fbc621d0850 2025.07.28 11:58:47.263604 [ 17557 ] {3c9e0129-81de-4c8a-aa24-3de4248c6319} executeQuery: Code: 60. DB::Exception: Table test_15.concurrent_optimize_table does not exist. (UNKNOWN_TABLE) (version 25.3.6.10636.altinitytest (altinity build)) (from [::1]:51804) (comment: 01103_optimize_drop_race_zookeeper.sh) (query 1, line 1) (in query: INSERT INTO concurrent_optimize_table SELECT rand(1), rand(2), 1 / rand(3), toString(rand(4)), [rand(5), rand(6)], rand(7) % 2 ? NULL : generateUUIDv4(), (rand(8), rand(9)) FROM numbers(10000)), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000a06a8eb 4. /build/src/Databases/IDatabase.cpp:41: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x0000000013dd565f 5. /build/src/Interpreters/DatabaseCatalog.cpp:442: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x00000000144f0869 6. /build/src/Interpreters/DatabaseCatalog.cpp:976: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x00000000144f6c88 7. /build/src/Interpreters/InterpreterInsertQuery.cpp:169: DB::InterpreterInsertQuery::getTable(DB::ASTInsertQuery&) @ 0x000000001492bf04 8. /build/src/Interpreters/InterpreterInsertQuery.cpp:829: DB::InterpreterInsertQuery::execute() @ 0x0000000014933938 9. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88dc9 10. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 11. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 12. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 13. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 14. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 16. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 17. ? @ 0x00007fbc6213eac3 18. ? @ 0x00007fbc621d0850 2025.07.28 11:58:47.308100 [ 3283 ] {a517e718-f374-4093-a52b-deefd6c94acc} executeQuery: Code: 60. DB::Exception: Table test_15.concurrent_optimize_table does not exist. (UNKNOWN_TABLE) (version 25.3.6.10636.altinitytest (altinity build)) (from [::1]:51812) (comment: 01103_optimize_drop_race_zookeeper.sh) (query 1, line 1) (in query: OPTIMIZE TABLE concurrent_optimize_table FINAL), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000a06a8eb 4. /build/src/Databases/IDatabase.cpp:41: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x0000000013dd565f 5. /build/src/Interpreters/DatabaseCatalog.cpp:442: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x00000000144f0869 6. /build/src/Interpreters/DatabaseCatalog.cpp:976: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x00000000144f6c88 7. /build/src/Interpreters/InterpreterOptimizeQuery.cpp:40: DB::InterpreterOptimizeQuery::execute() @ 0x0000000014cd71de 8. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88dc9 9. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 10. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 11. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 12. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 13. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 14. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 15. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 16. ? @ 0x00007fbc6213eac3 17. ? @ 0x00007fbc621d0850 2025.07.28 11:58:47.308284 [ 17557 ] {} TCPHandler: Code: 60. DB::Exception: Table test_15.concurrent_optimize_table does not exist. (UNKNOWN_TABLE), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000a06a8eb 4. /build/src/Databases/IDatabase.cpp:41: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x0000000013dd565f 5. /build/src/Interpreters/DatabaseCatalog.cpp:442: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x00000000144f0869 6. /build/src/Interpreters/DatabaseCatalog.cpp:976: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x00000000144f6c88 7. /build/src/Interpreters/InterpreterInsertQuery.cpp:169: DB::InterpreterInsertQuery::getTable(DB::ASTInsertQuery&) @ 0x000000001492bf04 8. /build/src/Interpreters/InterpreterInsertQuery.cpp:829: DB::InterpreterInsertQuery::execute() @ 0x0000000014933938 9. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88dc9 10. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 11. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 12. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 13. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 14. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 16. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 17. ? @ 0x00007fbc6213eac3 18. ? @ 0x00007fbc621d0850 2025.07.28 11:58:47.320623 [ 17208 ] {cc1ae413-1397-4cb6-bb0e-ae1991230a57} executeQuery: Code: 60. DB::Exception: Table test_15.concurrent_optimize_table does not exist. (UNKNOWN_TABLE) (version 25.3.6.10636.altinitytest (altinity build)) (from [::1]:51794) (comment: 01103_optimize_drop_race_zookeeper.sh) (query 1, line 1) (in query: OPTIMIZE TABLE concurrent_optimize_table FINAL), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000a06a8eb 4. /build/src/Databases/IDatabase.cpp:41: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x0000000013dd565f 5. /build/src/Interpreters/DatabaseCatalog.cpp:442: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x00000000144f0869 6. /build/src/Interpreters/DatabaseCatalog.cpp:976: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x00000000144f6c88 7. /build/src/Interpreters/InterpreterOptimizeQuery.cpp:40: DB::InterpreterOptimizeQuery::execute() @ 0x0000000014cd71de 8. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88dc9 9. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 10. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 11. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 12. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 13. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 14. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 15. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 16. ? @ 0x00007fbc6213eac3 17. ? @ 0x00007fbc621d0850 2025.07.28 11:58:47.322238 [ 3283 ] {} TCPHandler: Code: 60. DB::Exception: Table test_15.concurrent_optimize_table does not exist. (UNKNOWN_TABLE), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000a06a8eb 4. /build/src/Databases/IDatabase.cpp:41: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x0000000013dd565f 5. /build/src/Interpreters/DatabaseCatalog.cpp:442: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x00000000144f0869 6. /build/src/Interpreters/DatabaseCatalog.cpp:976: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x00000000144f6c88 7. /build/src/Interpreters/InterpreterOptimizeQuery.cpp:40: DB::InterpreterOptimizeQuery::execute() @ 0x0000000014cd71de 8. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88dc9 9. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 10. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 11. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 12. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 13. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 14. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 15. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 16. ? @ 0x00007fbc6213eac3 17. ? @ 0x00007fbc621d0850 2025.07.28 11:58:47.358203 [ 17208 ] {} TCPHandler: Code: 60. DB::Exception: Table test_15.concurrent_optimize_table does not exist. (UNKNOWN_TABLE), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000a06a8eb 4. /build/src/Databases/IDatabase.cpp:41: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x0000000013dd565f 5. /build/src/Interpreters/DatabaseCatalog.cpp:442: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x00000000144f0869 6. /build/src/Interpreters/DatabaseCatalog.cpp:976: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x00000000144f6c88 7. /build/src/Interpreters/InterpreterOptimizeQuery.cpp:40: DB::InterpreterOptimizeQuery::execute() @ 0x0000000014cd71de 8. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88dc9 9. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 10. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 11. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 12. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 13. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 14. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 15. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 16. ? @ 0x00007fbc6213eac3 17. ? @ 0x00007fbc621d0850 2025.07.28 11:58:47.458356 [ 17252 ] {013c730c-c2e6-473e-9daa-aa7186576a8d} executeQuery: Code: 60. DB::Exception: Table test_15.concurrent_optimize_table does not exist. (UNKNOWN_TABLE) (version 25.3.6.10636.altinitytest (altinity build)) (from [::1]:51808) (comment: 01103_optimize_drop_race_zookeeper.sh) (query 1, line 1) (in query: INSERT INTO concurrent_optimize_table SELECT rand(1), rand(2), 1 / rand(3), toString(rand(4)), [rand(5), rand(6)], rand(7) % 2 ? NULL : generateUUIDv4(), (rand(8), rand(9)) FROM numbers(10000)), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000a06a8eb 4. /build/src/Databases/IDatabase.cpp:41: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x0000000013dd565f 5. /build/src/Interpreters/DatabaseCatalog.cpp:442: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x00000000144f0869 6. /build/src/Interpreters/DatabaseCatalog.cpp:976: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x00000000144f6c88 7. /build/src/Interpreters/InterpreterInsertQuery.cpp:169: DB::InterpreterInsertQuery::getTable(DB::ASTInsertQuery&) @ 0x000000001492bf04 8. /build/src/Interpreters/InterpreterInsertQuery.cpp:829: DB::InterpreterInsertQuery::execute() @ 0x0000000014933938 9. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88dc9 10. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 11. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 12. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 13. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 14. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 16. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 17. ? @ 0x00007fbc6213eac3 18. ? @ 0x00007fbc621d0850 2025.07.28 11:58:47.510411 [ 17252 ] {} TCPHandler: Code: 60. DB::Exception: Table test_15.concurrent_optimize_table does not exist. (UNKNOWN_TABLE), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000a06a8eb 4. /build/src/Databases/IDatabase.cpp:41: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x0000000013dd565f 5. /build/src/Interpreters/DatabaseCatalog.cpp:442: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x00000000144f0869 6. /build/src/Interpreters/DatabaseCatalog.cpp:976: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x00000000144f6c88 7. /build/src/Interpreters/InterpreterInsertQuery.cpp:169: DB::InterpreterInsertQuery::getTable(DB::ASTInsertQuery&) @ 0x000000001492bf04 8. /build/src/Interpreters/InterpreterInsertQuery.cpp:829: DB::InterpreterInsertQuery::execute() @ 0x0000000014933938 9. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88dc9 10. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 11. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 12. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 13. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 14. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 16. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 17. ? @ 0x00007fbc6213eac3 18. ? @ 0x00007fbc621d0850 2025.07.28 11:58:47.523452 [ 3283 ] {837c8c5f-5d59-4451-b30e-cc76bae8c475} executeQuery: Code: 529. DB::Exception: OPTIMIZE cannot be done on this replica because it is not a leader. (NOT_A_LEADER) (version 25.3.6.10636.altinitytest (altinity build)) (from [::1]:51834) (comment: 01103_optimize_drop_race_zookeeper.sh) (query 1, line 1) (in query: OPTIMIZE TABLE concurrent_optimize_table FINAL), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000000a074fcb 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:6115: DB::StorageReplicatedMergeTree::optimize(std::shared_ptr const&, std::shared_ptr const&, std::shared_ptr const&, bool, bool, std::vector> const&, bool, std::shared_ptr) @ 0x0000000015f22a54 5. /build/src/Interpreters/InterpreterOptimizeQuery.cpp:84: DB::InterpreterOptimizeQuery::execute() @ 0x0000000014cd782e 6. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88dc9 7. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 8. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 9. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 10. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 11. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 12. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 13. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 14. ? @ 0x00007fbc6213eac3 15. ? @ 0x00007fbc621d0850 2025.07.28 11:58:47.559857 [ 3283 ] {} TCPHandler: Code: 529. DB::Exception: OPTIMIZE cannot be done on this replica because it is not a leader. (NOT_A_LEADER), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000000a074fcb 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:6115: DB::StorageReplicatedMergeTree::optimize(std::shared_ptr const&, std::shared_ptr const&, std::shared_ptr const&, bool, bool, std::vector> const&, bool, std::shared_ptr) @ 0x0000000015f22a54 5. /build/src/Interpreters/InterpreterOptimizeQuery.cpp:84: DB::InterpreterOptimizeQuery::execute() @ 0x0000000014cd782e 6. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88dc9 7. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 8. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 9. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 10. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 11. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 12. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 13. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 14. ? @ 0x00007fbc6213eac3 15. ? @ 0x00007fbc621d0850 2025.07.28 11:58:47.628196 [ 17371 ] {de2a5804-3180-4e1d-9e51-d5bec730e99b} executeQuery: Code: 60. DB::Exception: Table test_15.concurrent_optimize_table does not exist. (UNKNOWN_TABLE) (version 25.3.6.10636.altinitytest (altinity build)) (from [::1]:51860) (comment: 01103_optimize_drop_race_zookeeper.sh) (query 1, line 1) (in query: OPTIMIZE TABLE concurrent_optimize_table FINAL), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000a06a8eb 4. /build/src/Databases/IDatabase.cpp:41: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x0000000013dd565f 5. /build/src/Interpreters/DatabaseCatalog.cpp:442: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x00000000144f0869 6. /build/src/Interpreters/DatabaseCatalog.cpp:976: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x00000000144f6c88 7. /build/src/Interpreters/InterpreterOptimizeQuery.cpp:40: DB::InterpreterOptimizeQuery::execute() @ 0x0000000014cd71de 8. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88dc9 9. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 10. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 11. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 12. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 13. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 14. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 15. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 16. ? @ 0x00007fbc6213eac3 17. ? @ 0x00007fbc621d0850 2025.07.28 11:58:47.660029 [ 17371 ] {} TCPHandler: Code: 60. DB::Exception: Table test_15.concurrent_optimize_table does not exist. (UNKNOWN_TABLE), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000a06a8eb 4. /build/src/Databases/IDatabase.cpp:41: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x0000000013dd565f 5. /build/src/Interpreters/DatabaseCatalog.cpp:442: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x00000000144f0869 6. /build/src/Interpreters/DatabaseCatalog.cpp:976: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x00000000144f6c88 7. /build/src/Interpreters/InterpreterOptimizeQuery.cpp:40: DB::InterpreterOptimizeQuery::execute() @ 0x0000000014cd71de 8. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88dc9 9. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 10. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 11. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 12. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 13. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 14. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 15. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 16. ? @ 0x00007fbc6213eac3 17. ? @ 0x00007fbc621d0850 2025.07.28 11:58:47.746306 [ 17191 ] {52fd0ccc-22fe-47b3-8639-d62b9ce7a926} executeQuery: Code: 253. DB::Exception: Replica /clickhouse/tables/01103_optimize_drop_race_zookeeper_test_15/concurrent_optimize_table/replicas/1 already exists. (REPLICA_ALREADY_EXISTS) (version 25.3.6.10636.altinitytest (altinity build)) (from [::1]:51540) (comment: 01103_optimize_drop_race_zookeeper.sh) (query 2, line 2) (in query: CREATE TABLE concurrent_optimize_table (`a` UInt8, `b` Int16, `c` Float32, `d` String, `e` Array(UInt8), `f` Nullable(UUID), `g` Tuple(UInt8, UInt16)) ENGINE = ReplicatedMergeTree('/clickhouse/tables/01103_optimize_drop_race_zookeeper_test_15/concurrent_optimize_table', '1') PARTITION BY b % 10 ORDER BY a SETTINGS old_parts_lifetime = 1, cleanup_delay_period = 0, cleanup_delay_period_random_add = 0, cleanup_thread_preferred_points_per_iteration = 0, index_granularity = 31489, 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 = 20868213, compact_parts_max_bytes_to_buffer = 108362629, compact_parts_max_granules_to_buffer = 1, compact_parts_merge_max_bytes_to_prefetch_part = 18898448, merge_max_block_size = 13220, prefer_fetch_merged_part_size_threshold = 1, vertical_merge_algorithm_min_rows_to_activate = 1000000, vertical_merge_algorithm_min_columns_to_activate = 76, min_merge_bytes_to_use_direct_io = 10737418240, index_granularity_bytes = 7046892, use_const_adaptive_granularity = false, 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 = true, cache_populated_by_fetch = false, marks_compress_block_size = 84392, primary_key_compress_block_size = 23861, 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. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000a9b78ab 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:1237: DB::StorageReplicatedMergeTree::createReplicaAttempt(std::shared_ptr const&, std::shared_ptr) const @ 0x0000000015ea1634 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:1087: DB::StorageReplicatedMergeTree::createReplica(std::shared_ptr const&, DB::ZooKeeperRetriesInfo const&) const @ 0x0000000015e8c7b5 6. /build/src/Storages/StorageReplicatedMergeTree.cpp:624: DB::StorageReplicatedMergeTree::StorageReplicatedMergeTree(DB::TableZnodeInfo const&, DB::LoadingStrictnessLevel, DB::StorageID const&, String const&, DB::StorageInMemoryMetadata const&, std::shared_ptr, String const&, DB::MergeTreeData::MergingParams const&, std::unique_ptr>, bool, DB::ZooKeeperRetriesInfo const&) @ 0x0000000015e8979f 7. /build/contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: std::shared_ptr std::allocate_shared[abi:se190107], DB::TableZnodeInfo&, DB::LoadingStrictnessLevel const&, DB::StorageID const&, String const&, DB::StorageInMemoryMetadata&, std::shared_ptr&, String&, DB::MergeTreeData::MergingParams&, std::unique_ptr>, bool&, DB::ZooKeeperRetriesInfo&, 0>(std::allocator const&, DB::TableZnodeInfo&, DB::LoadingStrictnessLevel const&, DB::StorageID const&, String const&, DB::StorageInMemoryMetadata&, std::shared_ptr&, String&, DB::MergeTreeData::MergingParams&, std::unique_ptr>&&, bool&, DB::ZooKeeperRetriesInfo&) @ 0x000000001663250b 8. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:851: DB::create(DB::StorageFactory::Arguments const&) @ 0x000000001662ef92 9. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000015d81ea2 10. /build/src/Interpreters/InterpreterCreateQuery.cpp:1945: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x00000000149009bb 11. /build/src/Interpreters/InterpreterCreateQuery.cpp:1743: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000148f9aa9 12. /build/src/Interpreters/InterpreterCreateQuery.cpp:2352: DB::InterpreterCreateQuery::execute() @ 0x0000000014905a41 13. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88dc9 14. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 15. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 16. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 17. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 18. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 19. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 20. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 21. ? @ 0x00007fbc6213eac3 22. ? @ 0x00007fbc621d0850 2025.07.28 11:58:47.755091 [ 3967 ] {} test_13.rmt2 (7f9b740d-015c-470e-8cc6-8ba33be0dc63): auto DB::StorageReplicatedMergeTree::processQueueEntry(ReplicatedMergeTreeQueue::SelectedEntryPtr)::(anonymous class)::operator()(LogEntryPtr &) const: Code: 86. DB::HTTPException: Received error from remote server http://146b4357c08d:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Ftest%2F01165%2Ftest_13%2Frmt%2Freplicas%2F1&part=20250728_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.6.10636.altinitytest (altinity build)) '. (RECEIVED_ERROR_FROM_REMOTE_IO_SERVER), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.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 const&, int&&, String const&, unsigned long&&, String const&) @ 0x000000000feda8d9 4. /build/src/IO/HTTPCommon.cpp:104: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x000000000feda6e2 5. /build/src/IO/HTTPCommon.cpp:93: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x000000000feda537 6. /build/src/IO/ReadWriteBufferFromHTTP.cpp:277: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x000000001184a4c4 7. /build/src/IO/ReadWriteBufferFromHTTP.cpp:285: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x000000001184a615 8. /build/src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x000000001184ae59 9. /build/src/IO/ReadWriteBufferFromHTTP.cpp:472: void std::__function::__policy_invoker::__call_impl[abi:se190107]>(std::__function::__policy_storage const*) @ 0x000000001184cedd 10. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001184858b 11. /build/src/IO/ReadWriteBufferFromHTTP.cpp:465: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x000000001184bf0b 12. /build/src/IO/ReadBuffer.h:60: DB::ReadBuffer::next() @ 0x000000000a148c7b 13. /build/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) @ 0x0000000011849fb2 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]>&)>&, 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&) @ 0x0000000011841980 15. /build/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) @ 0x000000001621208e 16. /build/src/Storages/StorageReplicatedMergeTree.cpp:5228: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl[abi:se190107] const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000015f9a5fe 17. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000015ed8bfd 18. /build/src/Storages/StorageReplicatedMergeTree.cpp:2514: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x0000000015ec9aab 19. /build/src/Storages/StorageReplicatedMergeTree.cpp:2349: DB::StorageReplicatedMergeTree::executeLogEntry(DB::ReplicatedMergeTreeLogEntry&) @ 0x0000000015eba91b 20. /build/src/Storages/StorageReplicatedMergeTree.cpp:3876: bool std::__function::__policy_invoker&)>::__call_impl[abi:se190107])::$_1, bool (std::shared_ptr&)>>(std::__function::__policy_storage const*, std::shared_ptr&) @ 0x0000000015f9837e 21. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000165d6fc3 22. /build/src/Storages/StorageReplicatedMergeTree.cpp:3872: DB::StorageReplicatedMergeTree::processQueueEntry(std::shared_ptr) @ 0x0000000015efc18a 23. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001624c1b2 24. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000162f9c70 25. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x00000000162fa55a 26. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc6653 27. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000000fccc4c3 28. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc3d92 29. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fcca080 30. ? @ 0x00007fbc6213eac3 31. ? @ 0x00007fbc621d0850 (version 25.3.6.10636.altinitytest (altinity build)) 2025.07.28 11:58:47.759444 [ 17191 ] {} TCPHandler: Code: 253. DB::Exception: Replica /clickhouse/tables/01103_optimize_drop_race_zookeeper_test_15/concurrent_optimize_table/replicas/1 already exists. (REPLICA_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000a9b78ab 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:1237: DB::StorageReplicatedMergeTree::createReplicaAttempt(std::shared_ptr const&, std::shared_ptr) const @ 0x0000000015ea1634 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:1087: DB::StorageReplicatedMergeTree::createReplica(std::shared_ptr const&, DB::ZooKeeperRetriesInfo const&) const @ 0x0000000015e8c7b5 6. /build/src/Storages/StorageReplicatedMergeTree.cpp:624: DB::StorageReplicatedMergeTree::StorageReplicatedMergeTree(DB::TableZnodeInfo const&, DB::LoadingStrictnessLevel, DB::StorageID const&, String const&, DB::StorageInMemoryMetadata const&, std::shared_ptr, String const&, DB::MergeTreeData::MergingParams const&, std::unique_ptr>, bool, DB::ZooKeeperRetriesInfo const&) @ 0x0000000015e8979f 7. /build/contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: std::shared_ptr std::allocate_shared[abi:se190107], DB::TableZnodeInfo&, DB::LoadingStrictnessLevel const&, DB::StorageID const&, String const&, DB::StorageInMemoryMetadata&, std::shared_ptr&, String&, DB::MergeTreeData::MergingParams&, std::unique_ptr>, bool&, DB::ZooKeeperRetriesInfo&, 0>(std::allocator const&, DB::TableZnodeInfo&, DB::LoadingStrictnessLevel const&, DB::StorageID const&, String const&, DB::StorageInMemoryMetadata&, std::shared_ptr&, String&, DB::MergeTreeData::MergingParams&, std::unique_ptr>&&, bool&, DB::ZooKeeperRetriesInfo&) @ 0x000000001663250b 8. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:851: DB::create(DB::StorageFactory::Arguments const&) @ 0x000000001662ef92 9. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000015d81ea2 10. /build/src/Interpreters/InterpreterCreateQuery.cpp:1945: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x00000000149009bb 11. /build/src/Interpreters/InterpreterCreateQuery.cpp:1743: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000148f9aa9 12. /build/src/Interpreters/InterpreterCreateQuery.cpp:2352: DB::InterpreterCreateQuery::execute() @ 0x0000000014905a41 13. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88dc9 14. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 15. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 16. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 17. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 18. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 19. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 20. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 21. ? @ 0x00007fbc6213eac3 22. ? @ 0x00007fbc621d0850 2025.07.28 11:58:47.778632 [ 17252 ] {e4eedcb8-30a1-4f0c-a7cb-798b49a739e9} executeQuery: Code: 60. DB::Exception: Table test_15.concurrent_optimize_table does not exist. (UNKNOWN_TABLE) (version 25.3.6.10636.altinitytest (altinity build)) (from [::1]:51864) (comment: 01103_optimize_drop_race_zookeeper.sh) (query 1, line 1) (in query: INSERT INTO concurrent_optimize_table SELECT rand(1), rand(2), 1 / rand(3), toString(rand(4)), [rand(5), rand(6)], rand(7) % 2 ? NULL : generateUUIDv4(), (rand(8), rand(9)) FROM numbers(10000)), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000a06a8eb 4. /build/src/Databases/IDatabase.cpp:41: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x0000000013dd565f 5. /build/src/Interpreters/DatabaseCatalog.cpp:442: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x00000000144f0869 6. /build/src/Interpreters/DatabaseCatalog.cpp:976: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x00000000144f6c88 7. /build/src/Interpreters/InterpreterInsertQuery.cpp:169: DB::InterpreterInsertQuery::getTable(DB::ASTInsertQuery&) @ 0x000000001492bf04 8. /build/src/Interpreters/InterpreterInsertQuery.cpp:829: DB::InterpreterInsertQuery::execute() @ 0x0000000014933938 9. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88dc9 10. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 11. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 12. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 13. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 14. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 16. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 17. ? @ 0x00007fbc6213eac3 18. ? @ 0x00007fbc621d0850 2025.07.28 11:58:47.795805 [ 17252 ] {} TCPHandler: Code: 60. DB::Exception: Table test_15.concurrent_optimize_table does not exist. (UNKNOWN_TABLE), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000a06a8eb 4. /build/src/Databases/IDatabase.cpp:41: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x0000000013dd565f 5. /build/src/Interpreters/DatabaseCatalog.cpp:442: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x00000000144f0869 6. /build/src/Interpreters/DatabaseCatalog.cpp:976: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x00000000144f6c88 7. /build/src/Interpreters/InterpreterInsertQuery.cpp:169: DB::InterpreterInsertQuery::getTable(DB::ASTInsertQuery&) @ 0x000000001492bf04 8. /build/src/Interpreters/InterpreterInsertQuery.cpp:829: DB::InterpreterInsertQuery::execute() @ 0x0000000014933938 9. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88dc9 10. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 11. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 12. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 13. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 14. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 16. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 17. ? @ 0x00007fbc6213eac3 18. ? @ 0x00007fbc621d0850 2025.07.28 11:58:47.831945 [ 17371 ] {d4b91b98-559c-403c-ad2e-c45db53a6da2} executeQuery: Code: 60. DB::Exception: Table test_15.concurrent_optimize_table does not exist. (UNKNOWN_TABLE) (version 25.3.6.10636.altinitytest (altinity build)) (from [::1]:51900) (comment: 01103_optimize_drop_race_zookeeper.sh) (query 1, line 1) (in query: OPTIMIZE TABLE concurrent_optimize_table FINAL), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000a06a8eb 4. /build/src/Databases/IDatabase.cpp:41: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x0000000013dd565f 5. /build/src/Interpreters/DatabaseCatalog.cpp:442: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x00000000144f0869 6. /build/src/Interpreters/DatabaseCatalog.cpp:976: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x00000000144f6c88 7. /build/src/Interpreters/InterpreterOptimizeQuery.cpp:40: DB::InterpreterOptimizeQuery::execute() @ 0x0000000014cd71de 8. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88dc9 9. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 10. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 11. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 12. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 13. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 14. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 15. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 16. ? @ 0x00007fbc6213eac3 17. ? @ 0x00007fbc621d0850 2025.07.28 11:58:47.858592 [ 3283 ] {c08f24f3-89d1-4972-b93e-d7a167f7ab78} executeQuery: Code: 60. DB::Exception: Table test_15.concurrent_optimize_table does not exist. (UNKNOWN_TABLE) (version 25.3.6.10636.altinitytest (altinity build)) (from [::1]:51874) (comment: 01103_optimize_drop_race_zookeeper.sh) (query 1, line 1) (in query: OPTIMIZE TABLE concurrent_optimize_table FINAL), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000a06a8eb 4. /build/src/Databases/IDatabase.cpp:41: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x0000000013dd565f 5. /build/src/Interpreters/DatabaseCatalog.cpp:442: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x00000000144f0869 6. /build/src/Interpreters/DatabaseCatalog.cpp:976: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x00000000144f6c88 7. /build/src/Interpreters/InterpreterOptimizeQuery.cpp:40: DB::InterpreterOptimizeQuery::execute() @ 0x0000000014cd71de 8. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88dc9 9. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 10. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 11. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 12. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 13. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 14. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 15. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 16. ? @ 0x00007fbc6213eac3 17. ? @ 0x00007fbc621d0850 2025.07.28 11:58:47.872078 [ 17371 ] {} TCPHandler: Code: 60. DB::Exception: Table test_15.concurrent_optimize_table does not exist. (UNKNOWN_TABLE), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000a06a8eb 4. /build/src/Databases/IDatabase.cpp:41: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x0000000013dd565f 5. /build/src/Interpreters/DatabaseCatalog.cpp:442: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x00000000144f0869 6. /build/src/Interpreters/DatabaseCatalog.cpp:976: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x00000000144f6c88 7. /build/src/Interpreters/InterpreterOptimizeQuery.cpp:40: DB::InterpreterOptimizeQuery::execute() @ 0x0000000014cd71de 8. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88dc9 9. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 10. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 11. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 12. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 13. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 14. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 15. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 16. ? @ 0x00007fbc6213eac3 17. ? @ 0x00007fbc621d0850 2025.07.28 11:58:47.908207 [ 3283 ] {} TCPHandler: Code: 60. DB::Exception: Table test_15.concurrent_optimize_table does not exist. (UNKNOWN_TABLE), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000a06a8eb 4. /build/src/Databases/IDatabase.cpp:41: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x0000000013dd565f 5. /build/src/Interpreters/DatabaseCatalog.cpp:442: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x00000000144f0869 6. /build/src/Interpreters/DatabaseCatalog.cpp:976: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x00000000144f6c88 7. /build/src/Interpreters/InterpreterOptimizeQuery.cpp:40: DB::InterpreterOptimizeQuery::execute() @ 0x0000000014cd71de 8. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88dc9 9. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 10. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 11. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 12. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 13. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 14. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 15. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 16. ? @ 0x00007fbc6213eac3 17. ? @ 0x00007fbc621d0850 2025.07.28 11:58:47.970448 [ 4446 ] {25276e03-22e6-4830-9438-cf2132520c6f} executeQuery: Code: 253. DB::Exception: Replica /clickhouse/tables/01103_optimize_drop_race_zookeeper_test_15/concurrent_optimize_table/replicas/1 already exists. (REPLICA_ALREADY_EXISTS) (version 25.3.6.10636.altinitytest (altinity build)) (from [::1]:51574) (comment: 01103_optimize_drop_race_zookeeper.sh) (query 2, line 2) (in query: CREATE TABLE concurrent_optimize_table (`a` UInt8, `b` Int16, `c` Float32, `d` String, `e` Array(UInt8), `f` Nullable(UUID), `g` Tuple(UInt8, UInt16)) ENGINE = ReplicatedMergeTree('/clickhouse/tables/01103_optimize_drop_race_zookeeper_test_15/concurrent_optimize_table', '1') PARTITION BY b % 10 ORDER BY a SETTINGS old_parts_lifetime = 1, cleanup_delay_period = 0, cleanup_delay_period_random_add = 0, cleanup_thread_preferred_points_per_iteration = 0, index_granularity = 31489, 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 = 20868213, compact_parts_max_bytes_to_buffer = 108362629, compact_parts_max_granules_to_buffer = 1, compact_parts_merge_max_bytes_to_prefetch_part = 18898448, merge_max_block_size = 13220, prefer_fetch_merged_part_size_threshold = 1, vertical_merge_algorithm_min_rows_to_activate = 1000000, vertical_merge_algorithm_min_columns_to_activate = 76, min_merge_bytes_to_use_direct_io = 10737418240, index_granularity_bytes = 7046892, use_const_adaptive_granularity = false, 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 = true, cache_populated_by_fetch = false, marks_compress_block_size = 84392, primary_key_compress_block_size = 23861, 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. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000a9b78ab 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:1237: DB::StorageReplicatedMergeTree::createReplicaAttempt(std::shared_ptr const&, std::shared_ptr) const @ 0x0000000015ea1634 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:1087: DB::StorageReplicatedMergeTree::createReplica(std::shared_ptr const&, DB::ZooKeeperRetriesInfo const&) const @ 0x0000000015e8c7b5 6. /build/src/Storages/StorageReplicatedMergeTree.cpp:624: DB::StorageReplicatedMergeTree::StorageReplicatedMergeTree(DB::TableZnodeInfo const&, DB::LoadingStrictnessLevel, DB::StorageID const&, String const&, DB::StorageInMemoryMetadata const&, std::shared_ptr, String const&, DB::MergeTreeData::MergingParams const&, std::unique_ptr>, bool, DB::ZooKeeperRetriesInfo const&) @ 0x0000000015e8979f 7. /build/contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: std::shared_ptr std::allocate_shared[abi:se190107], DB::TableZnodeInfo&, DB::LoadingStrictnessLevel const&, DB::StorageID const&, String const&, DB::StorageInMemoryMetadata&, std::shared_ptr&, String&, DB::MergeTreeData::MergingParams&, std::unique_ptr>, bool&, DB::ZooKeeperRetriesInfo&, 0>(std::allocator const&, DB::TableZnodeInfo&, DB::LoadingStrictnessLevel const&, DB::StorageID const&, String const&, DB::StorageInMemoryMetadata&, std::shared_ptr&, String&, DB::MergeTreeData::MergingParams&, std::unique_ptr>&&, bool&, DB::ZooKeeperRetriesInfo&) @ 0x000000001663250b 8. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:851: DB::create(DB::StorageFactory::Arguments const&) @ 0x000000001662ef92 9. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000015d81ea2 10. /build/src/Interpreters/InterpreterCreateQuery.cpp:1945: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x00000000149009bb 11. /build/src/Interpreters/InterpreterCreateQuery.cpp:1743: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000148f9aa9 12. /build/src/Interpreters/InterpreterCreateQuery.cpp:2352: DB::InterpreterCreateQuery::execute() @ 0x0000000014905a41 13. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88dc9 14. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 15. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 16. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 17. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 18. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 19. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 20. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 21. ? @ 0x00007fbc6213eac3 22. ? @ 0x00007fbc621d0850 2025.07.28 11:58:47.992993 [ 4446 ] {} TCPHandler: Code: 253. DB::Exception: Replica /clickhouse/tables/01103_optimize_drop_race_zookeeper_test_15/concurrent_optimize_table/replicas/1 already exists. (REPLICA_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000a9b78ab 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:1237: DB::StorageReplicatedMergeTree::createReplicaAttempt(std::shared_ptr const&, std::shared_ptr) const @ 0x0000000015ea1634 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:1087: DB::StorageReplicatedMergeTree::createReplica(std::shared_ptr const&, DB::ZooKeeperRetriesInfo const&) const @ 0x0000000015e8c7b5 6. /build/src/Storages/StorageReplicatedMergeTree.cpp:624: DB::StorageReplicatedMergeTree::StorageReplicatedMergeTree(DB::TableZnodeInfo const&, DB::LoadingStrictnessLevel, DB::StorageID const&, String const&, DB::StorageInMemoryMetadata const&, std::shared_ptr, String const&, DB::MergeTreeData::MergingParams const&, std::unique_ptr>, bool, DB::ZooKeeperRetriesInfo const&) @ 0x0000000015e8979f 7. /build/contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: std::shared_ptr std::allocate_shared[abi:se190107], DB::TableZnodeInfo&, DB::LoadingStrictnessLevel const&, DB::StorageID const&, String const&, DB::StorageInMemoryMetadata&, std::shared_ptr&, String&, DB::MergeTreeData::MergingParams&, std::unique_ptr>, bool&, DB::ZooKeeperRetriesInfo&, 0>(std::allocator const&, DB::TableZnodeInfo&, DB::LoadingStrictnessLevel const&, DB::StorageID const&, String const&, DB::StorageInMemoryMetadata&, std::shared_ptr&, String&, DB::MergeTreeData::MergingParams&, std::unique_ptr>&&, bool&, DB::ZooKeeperRetriesInfo&) @ 0x000000001663250b 8. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:851: DB::create(DB::StorageFactory::Arguments const&) @ 0x000000001662ef92 9. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000015d81ea2 10. /build/src/Interpreters/InterpreterCreateQuery.cpp:1945: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x00000000149009bb 11. /build/src/Interpreters/InterpreterCreateQuery.cpp:1743: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000148f9aa9 12. /build/src/Interpreters/InterpreterCreateQuery.cpp:2352: DB::InterpreterCreateQuery::execute() @ 0x0000000014905a41 13. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88dc9 14. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 15. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 16. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 17. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 18. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 19. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 20. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 21. ? @ 0x00007fbc6213eac3 22. ? @ 0x00007fbc621d0850 2025.07.28 11:58:48.036564 [ 17252 ] {7874e2ad-0b59-427a-8815-d783622e0769} executeQuery: Code: 60. DB::Exception: Table test_15.concurrent_optimize_table does not exist. (UNKNOWN_TABLE) (version 25.3.6.10636.altinitytest (altinity build)) (from [::1]:51910) (comment: 01103_optimize_drop_race_zookeeper.sh) (query 1, line 1) (in query: INSERT INTO concurrent_optimize_table SELECT rand(1), rand(2), 1 / rand(3), toString(rand(4)), [rand(5), rand(6)], rand(7) % 2 ? NULL : generateUUIDv4(), (rand(8), rand(9)) FROM numbers(10000)), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000a06a8eb 4. /build/src/Databases/IDatabase.cpp:41: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x0000000013dd565f 5. /build/src/Interpreters/DatabaseCatalog.cpp:442: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x00000000144f0869 6. /build/src/Interpreters/DatabaseCatalog.cpp:976: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x00000000144f6c88 7. /build/src/Interpreters/InterpreterInsertQuery.cpp:169: DB::InterpreterInsertQuery::getTable(DB::ASTInsertQuery&) @ 0x000000001492bf04 8. /build/src/Interpreters/InterpreterInsertQuery.cpp:829: DB::InterpreterInsertQuery::execute() @ 0x0000000014933938 9. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88dc9 10. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 11. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 12. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 13. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 14. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 16. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 17. ? @ 0x00007fbc6213eac3 18. ? @ 0x00007fbc621d0850 2025.07.28 11:58:48.058415 [ 17252 ] {} TCPHandler: Code: 60. DB::Exception: Table test_15.concurrent_optimize_table does not exist. (UNKNOWN_TABLE), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000a06a8eb 4. /build/src/Databases/IDatabase.cpp:41: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x0000000013dd565f 5. /build/src/Interpreters/DatabaseCatalog.cpp:442: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x00000000144f0869 6. /build/src/Interpreters/DatabaseCatalog.cpp:976: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x00000000144f6c88 7. /build/src/Interpreters/InterpreterInsertQuery.cpp:169: DB::InterpreterInsertQuery::getTable(DB::ASTInsertQuery&) @ 0x000000001492bf04 8. /build/src/Interpreters/InterpreterInsertQuery.cpp:829: DB::InterpreterInsertQuery::execute() @ 0x0000000014933938 9. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88dc9 10. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 11. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 12. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 13. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 14. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 16. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 17. ? @ 0x00007fbc6213eac3 18. ? @ 0x00007fbc621d0850 2025.07.28 11:58:48.099201 [ 3283 ] {c7e495ae-50c7-40db-a2c2-823ded18db6a} executeQuery: Code: 60. DB::Exception: Table test_15.concurrent_optimize_table does not exist. (UNKNOWN_TABLE) (version 25.3.6.10636.altinitytest (altinity build)) (from [::1]:51924) (comment: 01103_optimize_drop_race_zookeeper.sh) (query 1, line 1) (in query: OPTIMIZE TABLE concurrent_optimize_table FINAL), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000a06a8eb 4. /build/src/Databases/IDatabase.cpp:41: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x0000000013dd565f 5. /build/src/Interpreters/DatabaseCatalog.cpp:442: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x00000000144f0869 6. /build/src/Interpreters/DatabaseCatalog.cpp:976: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x00000000144f6c88 7. /build/src/Interpreters/InterpreterOptimizeQuery.cpp:40: DB::InterpreterOptimizeQuery::execute() @ 0x0000000014cd71de 8. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88dc9 9. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 10. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 11. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 12. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 13. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 14. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 15. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 16. ? @ 0x00007fbc6213eac3 17. ? @ 0x00007fbc621d0850 2025.07.28 11:58:48.128509 [ 3283 ] {} TCPHandler: Code: 60. DB::Exception: Table test_15.concurrent_optimize_table does not exist. (UNKNOWN_TABLE), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000a06a8eb 4. /build/src/Databases/IDatabase.cpp:41: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x0000000013dd565f 5. /build/src/Interpreters/DatabaseCatalog.cpp:442: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x00000000144f0869 6. /build/src/Interpreters/DatabaseCatalog.cpp:976: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x00000000144f6c88 7. /build/src/Interpreters/InterpreterOptimizeQuery.cpp:40: DB::InterpreterOptimizeQuery::execute() @ 0x0000000014cd71de 8. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88dc9 9. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 10. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 11. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 12. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 13. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 14. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 15. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 16. ? @ 0x00007fbc6213eac3 17. ? @ 0x00007fbc621d0850 2025.07.28 11:58:48.246958 [ 3963 ] {} test_13.rmt2 (7f9b740d-015c-470e-8cc6-8ba33be0dc63): auto DB::StorageReplicatedMergeTree::processQueueEntry(ReplicatedMergeTreeQueue::SelectedEntryPtr)::(anonymous class)::operator()(LogEntryPtr &) const: Code: 86. DB::HTTPException: Received error from remote server http://146b4357c08d:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Ftest%2F01165%2Ftest_13%2Frmt%2Freplicas%2F1&part=20250728_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.6.10636.altinitytest (altinity build)) '. (RECEIVED_ERROR_FROM_REMOTE_IO_SERVER), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.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 const&, int&&, String const&, unsigned long&&, String const&) @ 0x000000000feda8d9 4. /build/src/IO/HTTPCommon.cpp:104: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x000000000feda6e2 5. /build/src/IO/HTTPCommon.cpp:93: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x000000000feda537 6. /build/src/IO/ReadWriteBufferFromHTTP.cpp:277: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x000000001184a4c4 7. /build/src/IO/ReadWriteBufferFromHTTP.cpp:285: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x000000001184a615 8. /build/src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x000000001184ae59 9. /build/src/IO/ReadWriteBufferFromHTTP.cpp:472: void std::__function::__policy_invoker::__call_impl[abi:se190107]>(std::__function::__policy_storage const*) @ 0x000000001184cedd 10. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001184858b 11. /build/src/IO/ReadWriteBufferFromHTTP.cpp:465: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x000000001184bf0b 12. /build/src/IO/ReadBuffer.h:60: DB::ReadBuffer::next() @ 0x000000000a148c7b 13. /build/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) @ 0x0000000011849fb2 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]>&)>&, 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&) @ 0x0000000011841980 15. /build/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) @ 0x000000001621208e 16. /build/src/Storages/StorageReplicatedMergeTree.cpp:5228: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl[abi:se190107] const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000015f9a5fe 17. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000015ed8bfd 18. /build/src/Storages/StorageReplicatedMergeTree.cpp:2514: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x0000000015ec9aab 19. /build/src/Storages/StorageReplicatedMergeTree.cpp:2349: DB::StorageReplicatedMergeTree::executeLogEntry(DB::ReplicatedMergeTreeLogEntry&) @ 0x0000000015eba91b 20. /build/src/Storages/StorageReplicatedMergeTree.cpp:3876: bool std::__function::__policy_invoker&)>::__call_impl[abi:se190107])::$_1, bool (std::shared_ptr&)>>(std::__function::__policy_storage const*, std::shared_ptr&) @ 0x0000000015f9837e 21. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000165d6fc3 22. /build/src/Storages/StorageReplicatedMergeTree.cpp:3872: DB::StorageReplicatedMergeTree::processQueueEntry(std::shared_ptr) @ 0x0000000015efc18a 23. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001624c1b2 24. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000162f9c70 25. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x00000000162fa55a 26. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc6653 27. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000000fccc4c3 28. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc3d92 29. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fcca080 30. ? @ 0x00007fbc6213eac3 31. ? @ 0x00007fbc621d0850 (version 25.3.6.10636.altinitytest (altinity build)) 2025.07.28 11:58:48.326635 [ 17611 ] {d14279be-9c30-4b7c-a444-22003b7e063d} executeQuery: Code: 242. DB::Exception: Table is in readonly mode due to shutdown: replica_path=/clickhouse/tables/01103_optimize_drop_race_zookeeper_test_15/concurrent_optimize_table/replicas/1. (TABLE_IS_READ_ONLY) (version 25.3.6.10636.altinitytest (altinity build)) (from [::1]:51824) (comment: 01103_optimize_drop_race_zookeeper.sh) (query 1, line 1) (in query: INSERT INTO concurrent_optimize_table SELECT rand(1), rand(2), 1 / rand(3), toString(rand(4)), [rand(5), rand(6)], rand(7) % 2 ? NULL : generateUUIDv4(), (rand(8), rand(9)) FROM numbers(10000)), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000a9b78ab 4. /build/src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:866: DB::ReplicatedMergeTreeSinkImpl::commitPart(std::shared_ptr const&, std::shared_ptr&, String const&, unsigned long)::'lambda1'()::operator()() const @ 0x000000001660eed7 5. /build/src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:1124: DB::ReplicatedMergeTreeSinkImpl::commitPart(std::shared_ptr const&, std::shared_ptr&, String const&, unsigned long)::'lambda2'()::operator()() const @ 0x000000001660d1f2 6. /build/src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:1157: void DB::ZooKeeperRetriesControl::retryLoop::commitPart(std::shared_ptr const&, std::shared_ptr&, String const&, unsigned long)::'lambda3'()&, void DB::ZooKeeperRetriesControl::retryLoop::commitPart(std::shared_ptr const&, std::shared_ptr&, String const&, unsigned long)::'lambda3'()>(DB::ReplicatedMergeTreeSinkImpl::commitPart(std::shared_ptr const&, std::shared_ptr&, String const&, unsigned long)::'lambda3'()&&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::commitPart(std::shared_ptr const&, std::shared_ptr&, String const&, unsigned long)::'lambda3'()&&, void DB::ZooKeeperRetriesControl::retryLoop::commitPart(std::shared_ptr const&, std::shared_ptr&, String const&, unsigned long)::'lambda3'()>(DB::ReplicatedMergeTreeSinkImpl::commitPart(std::shared_ptr const&, std::shared_ptr&, String const&, unsigned long)::'lambda3'()&&)::'lambda'()&&) @ 0x000000001660d07f 7. /build/src/Common/ZooKeeper/ZooKeeperRetries.h:52: DB::ReplicatedMergeTreeSinkImpl::commitPart(std::shared_ptr const&, std::shared_ptr&, String const&, unsigned long) @ 0x00000000165fd951 8. /build/src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:492: DB::ReplicatedMergeTreeSinkImpl::finishDelayedChunk(std::shared_ptr const&) @ 0x00000000165f277d 9. /build/src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:437: DB::ReplicatedMergeTreeSinkImpl::consume(DB::Chunk&) @ 0x00000000165fbd00 10. /build/src/Processors/Sinks/SinkToStorage.cpp:10: DB::SinkToStorage::onConsume(DB::Chunk) @ 0x0000000016cee093 11. /build/src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: void std::__function::__policy_invoker::__call_impl[abi:se190107]>(std::__function::__policy_storage const*) @ 0x0000000016c0ad89 12. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000016c0abf5 13. /build/src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: DB::ExceptionKeepingTransform::work() @ 0x0000000016c0a6fe 14. /build/src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x00000000169bd00f 15. /build/src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x00000000169b2105 16. /build/src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeSingleThread(unsigned long) @ 0x00000000169b23be 17. /build/src/Processors/Executors/PipelineExecutor.cpp:416: void std::__function::__policy_invoker::__call_impl[abi:se190107]>(std::__function::__policy_storage const*) @ 0x00000000169b2e3f 18. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc6653 19. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000000fccc4c3 20. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc3d92 21. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fcca080 22. ? @ 0x00007fbc6213eac3 23. ? @ 0x00007fbc621d0850 2025.07.28 11:58:48.340590 [ 5879 ] {6544ba41-61be-4ac7-8b3b-ee697c9b6edd} executeQuery: Code: 242. DB::Exception: Table is in readonly mode due to shutdown: replica_path=/clickhouse/tables/01103_optimize_drop_race_zookeeper_test_15/concurrent_optimize_table/replicas/1. (TABLE_IS_READ_ONLY) (version 25.3.6.10636.altinitytest (altinity build)) (from [::1]:51818) (comment: 01103_optimize_drop_race_zookeeper.sh) (query 1, line 1) (in query: INSERT INTO concurrent_optimize_table SELECT rand(1), rand(2), 1 / rand(3), toString(rand(4)), [rand(5), rand(6)], rand(7) % 2 ? NULL : generateUUIDv4(), (rand(8), rand(9)) FROM numbers(10000)), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000a9b78ab 4. /build/src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:866: DB::ReplicatedMergeTreeSinkImpl::commitPart(std::shared_ptr const&, std::shared_ptr&, String const&, unsigned long)::'lambda1'()::operator()() const @ 0x000000001660eed7 5. /build/src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:1124: DB::ReplicatedMergeTreeSinkImpl::commitPart(std::shared_ptr const&, std::shared_ptr&, String const&, unsigned long)::'lambda2'()::operator()() const @ 0x000000001660d1f2 6. /build/src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:1157: void DB::ZooKeeperRetriesControl::retryLoop::commitPart(std::shared_ptr const&, std::shared_ptr&, String const&, unsigned long)::'lambda3'()&, void DB::ZooKeeperRetriesControl::retryLoop::commitPart(std::shared_ptr const&, std::shared_ptr&, String const&, unsigned long)::'lambda3'()>(DB::ReplicatedMergeTreeSinkImpl::commitPart(std::shared_ptr const&, std::shared_ptr&, String const&, unsigned long)::'lambda3'()&&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::commitPart(std::shared_ptr const&, std::shared_ptr&, String const&, unsigned long)::'lambda3'()&&, void DB::ZooKeeperRetriesControl::retryLoop::commitPart(std::shared_ptr const&, std::shared_ptr&, String const&, unsigned long)::'lambda3'()>(DB::ReplicatedMergeTreeSinkImpl::commitPart(std::shared_ptr const&, std::shared_ptr&, String const&, unsigned long)::'lambda3'()&&)::'lambda'()&&) @ 0x000000001660d07f 7. /build/src/Common/ZooKeeper/ZooKeeperRetries.h:52: DB::ReplicatedMergeTreeSinkImpl::commitPart(std::shared_ptr const&, std::shared_ptr&, String const&, unsigned long) @ 0x00000000165fd951 8. /build/src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:492: DB::ReplicatedMergeTreeSinkImpl::finishDelayedChunk(std::shared_ptr const&) @ 0x00000000165f277d 9. /build/src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:437: DB::ReplicatedMergeTreeSinkImpl::consume(DB::Chunk&) @ 0x00000000165fbd00 10. /build/src/Processors/Sinks/SinkToStorage.cpp:10: DB::SinkToStorage::onConsume(DB::Chunk) @ 0x0000000016cee093 11. /build/src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: void std::__function::__policy_invoker::__call_impl[abi:se190107]>(std::__function::__policy_storage const*) @ 0x0000000016c0ad89 12. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000016c0abf5 13. /build/src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: DB::ExceptionKeepingTransform::work() @ 0x0000000016c0a6fe 14. /build/src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x00000000169bd00f 15. /build/src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x00000000169b2105 16. /build/src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeSingleThread(unsigned long) @ 0x00000000169b23be 17. /build/src/Processors/Executors/PipelineExecutor.cpp:416: void std::__function::__policy_invoker::__call_impl[abi:se190107]>(std::__function::__policy_storage const*) @ 0x00000000169b2e3f 18. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc6653 19. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000000fccc4c3 20. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc3d92 21. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fcca080 22. ? @ 0x00007fbc6213eac3 23. ? @ 0x00007fbc621d0850 2025.07.28 11:58:48.362533 [ 17611 ] {} TCPHandler: Code: 242. DB::Exception: Table is in readonly mode due to shutdown: replica_path=/clickhouse/tables/01103_optimize_drop_race_zookeeper_test_15/concurrent_optimize_table/replicas/1. (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000a9b78ab 4. /build/src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:866: DB::ReplicatedMergeTreeSinkImpl::commitPart(std::shared_ptr const&, std::shared_ptr&, String const&, unsigned long)::'lambda1'()::operator()() const @ 0x000000001660eed7 5. /build/src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:1124: DB::ReplicatedMergeTreeSinkImpl::commitPart(std::shared_ptr const&, std::shared_ptr&, String const&, unsigned long)::'lambda2'()::operator()() const @ 0x000000001660d1f2 6. /build/src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:1157: void DB::ZooKeeperRetriesControl::retryLoop::commitPart(std::shared_ptr const&, std::shared_ptr&, String const&, unsigned long)::'lambda3'()&, void DB::ZooKeeperRetriesControl::retryLoop::commitPart(std::shared_ptr const&, std::shared_ptr&, String const&, unsigned long)::'lambda3'()>(DB::ReplicatedMergeTreeSinkImpl::commitPart(std::shared_ptr const&, std::shared_ptr&, String const&, unsigned long)::'lambda3'()&&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::commitPart(std::shared_ptr const&, std::shared_ptr&, String const&, unsigned long)::'lambda3'()&&, void DB::ZooKeeperRetriesControl::retryLoop::commitPart(std::shared_ptr const&, std::shared_ptr&, String const&, unsigned long)::'lambda3'()>(DB::ReplicatedMergeTreeSinkImpl::commitPart(std::shared_ptr const&, std::shared_ptr&, String const&, unsigned long)::'lambda3'()&&)::'lambda'()&&) @ 0x000000001660d07f 7. /build/src/Common/ZooKeeper/ZooKeeperRetries.h:52: DB::ReplicatedMergeTreeSinkImpl::commitPart(std::shared_ptr const&, std::shared_ptr&, String const&, unsigned long) @ 0x00000000165fd951 8. /build/src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:492: DB::ReplicatedMergeTreeSinkImpl::finishDelayedChunk(std::shared_ptr const&) @ 0x00000000165f277d 9. /build/src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:437: DB::ReplicatedMergeTreeSinkImpl::consume(DB::Chunk&) @ 0x00000000165fbd00 10. /build/src/Processors/Sinks/SinkToStorage.cpp:10: DB::SinkToStorage::onConsume(DB::Chunk) @ 0x0000000016cee093 11. /build/src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: void std::__function::__policy_invoker::__call_impl[abi:se190107]>(std::__function::__policy_storage const*) @ 0x0000000016c0ad89 12. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000016c0abf5 13. /build/src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: DB::ExceptionKeepingTransform::work() @ 0x0000000016c0a6fe 14. /build/src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x00000000169bd00f 15. /build/src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x00000000169b2105 16. /build/src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeSingleThread(unsigned long) @ 0x00000000169b23be 17. /build/src/Processors/Executors/PipelineExecutor.cpp:416: void std::__function::__policy_invoker::__call_impl[abi:se190107]>(std::__function::__policy_storage const*) @ 0x00000000169b2e3f 18. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc6653 19. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000000fccc4c3 20. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc3d92 21. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fcca080 22. ? @ 0x00007fbc6213eac3 23. ? @ 0x00007fbc621d0850 Job's origin stack trace: 0. /build/src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000000fc33b84 1. /build/src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000000fcc2ea7 2. /build/src/Common/ThreadPool.cpp:401: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fcc7f1c 3. /build/src/Common/ThreadPool.cpp:494: ThreadPoolImpl>::scheduleOrThrowOnError(std::function, Priority) @ 0x000000000fcc7a0e 4. /build/src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::spawnThreadsImpl() @ 0x00000000169b2c0c 5. /build/src/Processors/Executors/PipelineExecutor.cpp:394: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x00000000169b0ba7 6. /build/src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x00000000169b03f4 7. /build/src/Processors/Executors/CompletedPipelineExecutor.cpp:42: void std::__function::__policy_invoker::__call_impl[abi:se190107]::ThreadFromGlobalPoolImpl(DB::CompletedPipelineExecutor::execute()::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169af7e1 8. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc3d92 9. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fcca080 10. ? @ 0x00007fbc6213eac3 11. ? @ 0x00007fbc621d0850 Job's origin stack trace: 0. /build/src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000000fc33b84 1. /build/src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000000fcc2ea7 2. /build/src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fcc535c 3. /build/src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000000fcc584d 4. /build/src/Common/ThreadPool.h:279: DB::CompletedPipelineExecutor::execute() @ 0x00000000169af267 5. /build/src/Server/TCPHandler.cpp:707: DB::TCPHandler::runImpl() @ 0x00000000168e6b2e 6. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 7. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 8. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 9. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 10. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 11. ? @ 0x00007fbc6213eac3 12. ? @ 0x00007fbc621d0850 2025.07.28 11:58:48.395923 [ 5879 ] {} TCPHandler: Code: 242. DB::Exception: Table is in readonly mode due to shutdown: replica_path=/clickhouse/tables/01103_optimize_drop_race_zookeeper_test_15/concurrent_optimize_table/replicas/1. (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000a9b78ab 4. /build/src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:866: DB::ReplicatedMergeTreeSinkImpl::commitPart(std::shared_ptr const&, std::shared_ptr&, String const&, unsigned long)::'lambda1'()::operator()() const @ 0x000000001660eed7 5. /build/src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:1124: DB::ReplicatedMergeTreeSinkImpl::commitPart(std::shared_ptr const&, std::shared_ptr&, String const&, unsigned long)::'lambda2'()::operator()() const @ 0x000000001660d1f2 6. /build/src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:1157: void DB::ZooKeeperRetriesControl::retryLoop::commitPart(std::shared_ptr const&, std::shared_ptr&, String const&, unsigned long)::'lambda3'()&, void DB::ZooKeeperRetriesControl::retryLoop::commitPart(std::shared_ptr const&, std::shared_ptr&, String const&, unsigned long)::'lambda3'()>(DB::ReplicatedMergeTreeSinkImpl::commitPart(std::shared_ptr const&, std::shared_ptr&, String const&, unsigned long)::'lambda3'()&&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::commitPart(std::shared_ptr const&, std::shared_ptr&, String const&, unsigned long)::'lambda3'()&&, void DB::ZooKeeperRetriesControl::retryLoop::commitPart(std::shared_ptr const&, std::shared_ptr&, String const&, unsigned long)::'lambda3'()>(DB::ReplicatedMergeTreeSinkImpl::commitPart(std::shared_ptr const&, std::shared_ptr&, String const&, unsigned long)::'lambda3'()&&)::'lambda'()&&) @ 0x000000001660d07f 7. /build/src/Common/ZooKeeper/ZooKeeperRetries.h:52: DB::ReplicatedMergeTreeSinkImpl::commitPart(std::shared_ptr const&, std::shared_ptr&, String const&, unsigned long) @ 0x00000000165fd951 8. /build/src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:492: DB::ReplicatedMergeTreeSinkImpl::finishDelayedChunk(std::shared_ptr const&) @ 0x00000000165f277d 9. /build/src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:437: DB::ReplicatedMergeTreeSinkImpl::consume(DB::Chunk&) @ 0x00000000165fbd00 10. /build/src/Processors/Sinks/SinkToStorage.cpp:10: DB::SinkToStorage::onConsume(DB::Chunk) @ 0x0000000016cee093 11. /build/src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: void std::__function::__policy_invoker::__call_impl[abi:se190107]>(std::__function::__policy_storage const*) @ 0x0000000016c0ad89 12. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000016c0abf5 13. /build/src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: DB::ExceptionKeepingTransform::work() @ 0x0000000016c0a6fe 14. /build/src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x00000000169bd00f 15. /build/src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x00000000169b2105 16. /build/src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeSingleThread(unsigned long) @ 0x00000000169b23be 17. /build/src/Processors/Executors/PipelineExecutor.cpp:416: void std::__function::__policy_invoker::__call_impl[abi:se190107]>(std::__function::__policy_storage const*) @ 0x00000000169b2e3f 18. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc6653 19. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000000fccc4c3 20. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc3d92 21. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fcca080 22. ? @ 0x00007fbc6213eac3 23. ? @ 0x00007fbc621d0850 Job's origin stack trace: 0. /build/src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000000fc33b84 1. /build/src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000000fcc2ea7 2. /build/src/Common/ThreadPool.cpp:401: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fcc7f1c 3. /build/src/Common/ThreadPool.cpp:494: ThreadPoolImpl>::scheduleOrThrowOnError(std::function, Priority) @ 0x000000000fcc7a0e 4. /build/src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::spawnThreadsImpl() @ 0x00000000169b2c0c 5. /build/src/Processors/Executors/PipelineExecutor.cpp:394: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x00000000169b0ba7 6. /build/src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x00000000169b03f4 7. /build/src/Processors/Executors/CompletedPipelineExecutor.cpp:42: void std::__function::__policy_invoker::__call_impl[abi:se190107]::ThreadFromGlobalPoolImpl(DB::CompletedPipelineExecutor::execute()::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169af7e1 8. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc3d92 9. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fcca080 10. ? @ 0x00007fbc6213eac3 11. ? @ 0x00007fbc621d0850 Job's origin stack trace: 0. /build/src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000000fc33b84 1. /build/src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000000fcc2ea7 2. /build/src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fcc535c 3. /build/src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000000fcc584d 4. /build/src/Common/ThreadPool.h:279: DB::CompletedPipelineExecutor::execute() @ 0x00000000169af267 5. /build/src/Server/TCPHandler.cpp:707: DB::TCPHandler::runImpl() @ 0x00000000168e6b2e 6. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 7. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 8. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 9. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 10. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 11. ? @ 0x00007fbc6213eac3 12. ? @ 0x00007fbc621d0850 2025.07.28 11:58:48.463834 [ 17252 ] {f2ed4b06-574e-42f9-8477-f6ba06872ef3} executeQuery: Code: 60. DB::Exception: Table test_15.concurrent_optimize_table does not exist. (UNKNOWN_TABLE) (version 25.3.6.10636.altinitytest (altinity build)) (from [::1]:51926) (comment: 01103_optimize_drop_race_zookeeper.sh) (query 1, line 1) (in query: INSERT INTO concurrent_optimize_table SELECT rand(1), rand(2), 1 / rand(3), toString(rand(4)), [rand(5), rand(6)], rand(7) % 2 ? NULL : generateUUIDv4(), (rand(8), rand(9)) FROM numbers(10000)), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000a06a8eb 4. /build/src/Databases/IDatabase.cpp:41: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x0000000013dd565f 5. /build/src/Interpreters/DatabaseCatalog.cpp:442: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x00000000144f0869 6. /build/src/Interpreters/DatabaseCatalog.cpp:976: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x00000000144f6c88 7. /build/src/Interpreters/InterpreterInsertQuery.cpp:169: DB::InterpreterInsertQuery::getTable(DB::ASTInsertQuery&) @ 0x000000001492bf04 8. /build/src/Interpreters/InterpreterInsertQuery.cpp:829: DB::InterpreterInsertQuery::execute() @ 0x0000000014933938 9. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88dc9 10. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 11. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 12. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 13. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 14. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 16. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 17. ? @ 0x00007fbc6213eac3 18. ? @ 0x00007fbc621d0850 2025.07.28 11:58:48.474438 [ 7630 ] {b94377bf-513e-42d9-bfb8-909d6dee3403} executeQuery: Code: 60. DB::Exception: Table test_15.concurrent_optimize_table does not exist. (UNKNOWN_TABLE) (version 25.3.6.10636.altinitytest (altinity build)) (from [::1]:51952) (comment: 01103_optimize_drop_race_zookeeper.sh) (query 1, line 1) (in query: OPTIMIZE TABLE concurrent_optimize_table FINAL), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000a06a8eb 4. /build/src/Databases/IDatabase.cpp:41: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x0000000013dd565f 5. /build/src/Interpreters/DatabaseCatalog.cpp:442: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x00000000144f0869 6. /build/src/Interpreters/DatabaseCatalog.cpp:976: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x00000000144f6c88 7. /build/src/Interpreters/InterpreterOptimizeQuery.cpp:40: DB::InterpreterOptimizeQuery::execute() @ 0x0000000014cd71de 8. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88dc9 9. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 10. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 11. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 12. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 13. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 14. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 15. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 16. ? @ 0x00007fbc6213eac3 17. ? @ 0x00007fbc621d0850 2025.07.28 11:58:48.504036 [ 7630 ] {} TCPHandler: Code: 60. DB::Exception: Table test_15.concurrent_optimize_table does not exist. (UNKNOWN_TABLE), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000a06a8eb 4. /build/src/Databases/IDatabase.cpp:41: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x0000000013dd565f 5. /build/src/Interpreters/DatabaseCatalog.cpp:442: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x00000000144f0869 6. /build/src/Interpreters/DatabaseCatalog.cpp:976: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x00000000144f6c88 7. /build/src/Interpreters/InterpreterOptimizeQuery.cpp:40: DB::InterpreterOptimizeQuery::execute() @ 0x0000000014cd71de 8. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88dc9 9. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 10. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 11. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 12. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 13. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 14. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 15. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 16. ? @ 0x00007fbc6213eac3 17. ? @ 0x00007fbc621d0850 2025.07.28 11:58:48.515945 [ 17252 ] {} TCPHandler: Code: 60. DB::Exception: Table test_15.concurrent_optimize_table does not exist. (UNKNOWN_TABLE), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000a06a8eb 4. /build/src/Databases/IDatabase.cpp:41: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x0000000013dd565f 5. /build/src/Interpreters/DatabaseCatalog.cpp:442: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x00000000144f0869 6. /build/src/Interpreters/DatabaseCatalog.cpp:976: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x00000000144f6c88 7. /build/src/Interpreters/InterpreterInsertQuery.cpp:169: DB::InterpreterInsertQuery::getTable(DB::ASTInsertQuery&) @ 0x000000001492bf04 8. /build/src/Interpreters/InterpreterInsertQuery.cpp:829: DB::InterpreterInsertQuery::execute() @ 0x0000000014933938 9. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88dc9 10. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 11. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 12. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 13. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 14. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 16. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 17. ? @ 0x00007fbc6213eac3 18. ? @ 0x00007fbc621d0850 2025.07.28 11:58:48.599239 [ 17232 ] {691053b0-60d5-4db4-b1be-1bc9505601c2} executeQuery: Code: 242. DB::Exception: Table is in readonly mode due to shutdown: replica_path=/clickhouse/tables/01103_optimize_drop_race_zookeeper_test_15/concurrent_optimize_table/replicas/1. (TABLE_IS_READ_ONLY) (version 25.3.6.10636.altinitytest (altinity build)) (from [::1]:51858) (comment: 01103_optimize_drop_race_zookeeper.sh) (query 1, line 1) (in query: INSERT INTO concurrent_optimize_table SELECT rand(1), rand(2), 1 / rand(3), toString(rand(4)), [rand(5), rand(6)], rand(7) % 2 ? NULL : generateUUIDv4(), (rand(8), rand(9)) FROM numbers(10000)), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000a9b78ab 4. /build/src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:866: DB::ReplicatedMergeTreeSinkImpl::commitPart(std::shared_ptr const&, std::shared_ptr&, String const&, unsigned long)::'lambda1'()::operator()() const @ 0x000000001660eed7 5. /build/src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:1124: DB::ReplicatedMergeTreeSinkImpl::commitPart(std::shared_ptr const&, std::shared_ptr&, String const&, unsigned long)::'lambda2'()::operator()() const @ 0x000000001660d1f2 6. /build/src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:1157: void DB::ZooKeeperRetriesControl::retryLoop::commitPart(std::shared_ptr const&, std::shared_ptr&, String const&, unsigned long)::'lambda3'()&, void DB::ZooKeeperRetriesControl::retryLoop::commitPart(std::shared_ptr const&, std::shared_ptr&, String const&, unsigned long)::'lambda3'()>(DB::ReplicatedMergeTreeSinkImpl::commitPart(std::shared_ptr const&, std::shared_ptr&, String const&, unsigned long)::'lambda3'()&&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::commitPart(std::shared_ptr const&, std::shared_ptr&, String const&, unsigned long)::'lambda3'()&&, void DB::ZooKeeperRetriesControl::retryLoop::commitPart(std::shared_ptr const&, std::shared_ptr&, String const&, unsigned long)::'lambda3'()>(DB::ReplicatedMergeTreeSinkImpl::commitPart(std::shared_ptr const&, std::shared_ptr&, String const&, unsigned long)::'lambda3'()&&)::'lambda'()&&) @ 0x000000001660d07f 7. /build/src/Common/ZooKeeper/ZooKeeperRetries.h:52: DB::ReplicatedMergeTreeSinkImpl::commitPart(std::shared_ptr const&, std::shared_ptr&, String const&, unsigned long) @ 0x00000000165fd951 8. /build/src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:492: DB::ReplicatedMergeTreeSinkImpl::finishDelayedChunk(std::shared_ptr const&) @ 0x00000000165f277d 9. /build/src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:437: DB::ReplicatedMergeTreeSinkImpl::consume(DB::Chunk&) @ 0x00000000165fbd00 10. /build/src/Processors/Sinks/SinkToStorage.cpp:10: DB::SinkToStorage::onConsume(DB::Chunk) @ 0x0000000016cee093 11. /build/src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: void std::__function::__policy_invoker::__call_impl[abi:se190107]>(std::__function::__policy_storage const*) @ 0x0000000016c0ad89 12. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000016c0abf5 13. /build/src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: DB::ExceptionKeepingTransform::work() @ 0x0000000016c0a6fe 14. /build/src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x00000000169bd00f 15. /build/src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x00000000169b2105 16. /build/src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeSingleThread(unsigned long) @ 0x00000000169b23be 17. /build/src/Processors/Executors/PipelineExecutor.cpp:416: void std::__function::__policy_invoker::__call_impl[abi:se190107]>(std::__function::__policy_storage const*) @ 0x00000000169b2e3f 18. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc6653 19. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000000fccc4c3 20. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc3d92 21. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fcca080 22. ? @ 0x00007fbc6213eac3 23. ? @ 0x00007fbc621d0850 2025.07.28 11:58:48.615280 [ 17611 ] {b1323560-20e8-49ad-90df-9a0232fb77ea} executeQuery: Code: 60. DB::Exception: Table test_15.concurrent_optimize_table does not exist. (UNKNOWN_TABLE) (version 25.3.6.10636.altinitytest (altinity build)) (from [::1]:51980) (comment: 01103_optimize_drop_race_zookeeper.sh) (query 1, line 1) (in query: INSERT INTO concurrent_optimize_table SELECT rand(1), rand(2), 1 / rand(3), toString(rand(4)), [rand(5), rand(6)], rand(7) % 2 ? NULL : generateUUIDv4(), (rand(8), rand(9)) FROM numbers(10000)), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000a06a8eb 4. /build/src/Databases/IDatabase.cpp:41: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x0000000013dd565f 5. /build/src/Interpreters/DatabaseCatalog.cpp:442: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x00000000144f0869 6. /build/src/Interpreters/DatabaseCatalog.cpp:976: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x00000000144f6c88 7. /build/src/Interpreters/InterpreterInsertQuery.cpp:169: DB::InterpreterInsertQuery::getTable(DB::ASTInsertQuery&) @ 0x000000001492bf04 8. /build/src/Interpreters/InterpreterInsertQuery.cpp:829: DB::InterpreterInsertQuery::execute() @ 0x0000000014933938 9. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88dc9 10. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 11. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 12. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 13. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 14. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 16. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 17. ? @ 0x00007fbc6213eac3 18. ? @ 0x00007fbc621d0850 2025.07.28 11:58:48.643814 [ 17611 ] {} TCPHandler: Code: 60. DB::Exception: Table test_15.concurrent_optimize_table does not exist. (UNKNOWN_TABLE), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000a06a8eb 4. /build/src/Databases/IDatabase.cpp:41: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x0000000013dd565f 5. /build/src/Interpreters/DatabaseCatalog.cpp:442: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x00000000144f0869 6. /build/src/Interpreters/DatabaseCatalog.cpp:976: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x00000000144f6c88 7. /build/src/Interpreters/InterpreterInsertQuery.cpp:169: DB::InterpreterInsertQuery::getTable(DB::ASTInsertQuery&) @ 0x000000001492bf04 8. /build/src/Interpreters/InterpreterInsertQuery.cpp:829: DB::InterpreterInsertQuery::execute() @ 0x0000000014933938 9. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88dc9 10. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 11. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 12. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 13. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 14. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 16. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 17. ? @ 0x00007fbc6213eac3 18. ? @ 0x00007fbc621d0850 2025.07.28 11:58:48.659698 [ 17232 ] {} TCPHandler: Code: 242. DB::Exception: Table is in readonly mode due to shutdown: replica_path=/clickhouse/tables/01103_optimize_drop_race_zookeeper_test_15/concurrent_optimize_table/replicas/1. (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000a9b78ab 4. /build/src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:866: DB::ReplicatedMergeTreeSinkImpl::commitPart(std::shared_ptr const&, std::shared_ptr&, String const&, unsigned long)::'lambda1'()::operator()() const @ 0x000000001660eed7 5. /build/src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:1124: DB::ReplicatedMergeTreeSinkImpl::commitPart(std::shared_ptr const&, std::shared_ptr&, String const&, unsigned long)::'lambda2'()::operator()() const @ 0x000000001660d1f2 6. /build/src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:1157: void DB::ZooKeeperRetriesControl::retryLoop::commitPart(std::shared_ptr const&, std::shared_ptr&, String const&, unsigned long)::'lambda3'()&, void DB::ZooKeeperRetriesControl::retryLoop::commitPart(std::shared_ptr const&, std::shared_ptr&, String const&, unsigned long)::'lambda3'()>(DB::ReplicatedMergeTreeSinkImpl::commitPart(std::shared_ptr const&, std::shared_ptr&, String const&, unsigned long)::'lambda3'()&&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::commitPart(std::shared_ptr const&, std::shared_ptr&, String const&, unsigned long)::'lambda3'()&&, void DB::ZooKeeperRetriesControl::retryLoop::commitPart(std::shared_ptr const&, std::shared_ptr&, String const&, unsigned long)::'lambda3'()>(DB::ReplicatedMergeTreeSinkImpl::commitPart(std::shared_ptr const&, std::shared_ptr&, String const&, unsigned long)::'lambda3'()&&)::'lambda'()&&) @ 0x000000001660d07f 7. /build/src/Common/ZooKeeper/ZooKeeperRetries.h:52: DB::ReplicatedMergeTreeSinkImpl::commitPart(std::shared_ptr const&, std::shared_ptr&, String const&, unsigned long) @ 0x00000000165fd951 8. /build/src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:492: DB::ReplicatedMergeTreeSinkImpl::finishDelayedChunk(std::shared_ptr const&) @ 0x00000000165f277d 9. /build/src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:437: DB::ReplicatedMergeTreeSinkImpl::consume(DB::Chunk&) @ 0x00000000165fbd00 10. /build/src/Processors/Sinks/SinkToStorage.cpp:10: DB::SinkToStorage::onConsume(DB::Chunk) @ 0x0000000016cee093 11. /build/src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: void std::__function::__policy_invoker::__call_impl[abi:se190107]>(std::__function::__policy_storage const*) @ 0x0000000016c0ad89 12. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000016c0abf5 13. /build/src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: DB::ExceptionKeepingTransform::work() @ 0x0000000016c0a6fe 14. /build/src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x00000000169bd00f 15. /build/src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x00000000169b2105 16. /build/src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeSingleThread(unsigned long) @ 0x00000000169b23be 17. /build/src/Processors/Executors/PipelineExecutor.cpp:416: void std::__function::__policy_invoker::__call_impl[abi:se190107]>(std::__function::__policy_storage const*) @ 0x00000000169b2e3f 18. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc6653 19. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000000fccc4c3 20. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc3d92 21. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fcca080 22. ? @ 0x00007fbc6213eac3 23. ? @ 0x00007fbc621d0850 Job's origin stack trace: 0. /build/src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000000fc33b84 1. /build/src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000000fcc2ea7 2. /build/src/Common/ThreadPool.cpp:401: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fcc7f1c 3. /build/src/Common/ThreadPool.cpp:494: ThreadPoolImpl>::scheduleOrThrowOnError(std::function, Priority) @ 0x000000000fcc7a0e 4. /build/src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::spawnThreadsImpl() @ 0x00000000169b2c0c 5. /build/src/Processors/Executors/PipelineExecutor.cpp:394: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x00000000169b0ba7 6. /build/src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x00000000169b03f4 7. /build/src/Processors/Executors/CompletedPipelineExecutor.cpp:42: void std::__function::__policy_invoker::__call_impl[abi:se190107]::ThreadFromGlobalPoolImpl(DB::CompletedPipelineExecutor::execute()::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169af7e1 8. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc3d92 9. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fcca080 10. ? @ 0x00007fbc6213eac3 11. ? @ 0x00007fbc621d0850 Job's origin stack trace: 0. /build/src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000000fc33b84 1. /build/src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000000fcc2ea7 2. /build/src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fcc535c 3. /build/src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000000fcc584d 4. /build/src/Common/ThreadPool.h:279: DB::CompletedPipelineExecutor::execute() @ 0x00000000169af267 5. /build/src/Server/TCPHandler.cpp:707: DB::TCPHandler::runImpl() @ 0x00000000168e6b2e 6. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 7. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 8. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 9. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 10. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 11. ? @ 0x00007fbc6213eac3 12. ? @ 0x00007fbc621d0850 2025.07.28 11:58:48.702069 [ 17321 ] {5e5a416e-e830-48fc-ba88-e478fbb7c3ec} executeQuery: Code: 60. DB::Exception: Table test_15.concurrent_optimize_table does not exist. (UNKNOWN_TABLE) (version 25.3.6.10636.altinitytest (altinity build)) (from [::1]:51988) (comment: 01103_optimize_drop_race_zookeeper.sh) (query 1, line 1) (in query: INSERT INTO concurrent_optimize_table SELECT rand(1), rand(2), 1 / rand(3), toString(rand(4)), [rand(5), rand(6)], rand(7) % 2 ? NULL : generateUUIDv4(), (rand(8), rand(9)) FROM numbers(10000)), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000a06a8eb 4. /build/src/Databases/IDatabase.cpp:41: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x0000000013dd565f 5. /build/src/Interpreters/DatabaseCatalog.cpp:442: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x00000000144f0869 6. /build/src/Interpreters/DatabaseCatalog.cpp:976: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x00000000144f6c88 7. /build/src/Interpreters/InterpreterInsertQuery.cpp:169: DB::InterpreterInsertQuery::getTable(DB::ASTInsertQuery&) @ 0x000000001492bf04 8. /build/src/Interpreters/InterpreterInsertQuery.cpp:829: DB::InterpreterInsertQuery::execute() @ 0x0000000014933938 9. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88dc9 10. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 11. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 12. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 13. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 14. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 16. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 17. ? @ 0x00007fbc6213eac3 18. ? @ 0x00007fbc621d0850 2025.07.28 11:58:48.713204 [ 17321 ] {} TCPHandler: Code: 60. DB::Exception: Table test_15.concurrent_optimize_table does not exist. (UNKNOWN_TABLE), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000a06a8eb 4. /build/src/Databases/IDatabase.cpp:41: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x0000000013dd565f 5. /build/src/Interpreters/DatabaseCatalog.cpp:442: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x00000000144f0869 6. /build/src/Interpreters/DatabaseCatalog.cpp:976: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x00000000144f6c88 7. /build/src/Interpreters/InterpreterInsertQuery.cpp:169: DB::InterpreterInsertQuery::getTable(DB::ASTInsertQuery&) @ 0x000000001492bf04 8. /build/src/Interpreters/InterpreterInsertQuery.cpp:829: DB::InterpreterInsertQuery::execute() @ 0x0000000014933938 9. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88dc9 10. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 11. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 12. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 13. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 14. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 16. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 17. ? @ 0x00007fbc6213eac3 18. ? @ 0x00007fbc621d0850 2025.07.28 11:58:48.748070 [ 4900 ] {b771bd83-141a-4113-b931-91e9f28bd484} executeQuery: Code: 60. DB::Exception: Table test_15.concurrent_optimize_table does not exist. (UNKNOWN_TABLE) (version 25.3.6.10636.altinitytest (altinity build)) (from [::1]:52004) (comment: 01103_optimize_drop_race_zookeeper.sh) (query 1, line 1) (in query: OPTIMIZE TABLE concurrent_optimize_table FINAL), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000a06a8eb 4. /build/src/Databases/IDatabase.cpp:41: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x0000000013dd565f 5. /build/src/Interpreters/DatabaseCatalog.cpp:442: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x00000000144f0869 6. /build/src/Interpreters/DatabaseCatalog.cpp:976: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x00000000144f6c88 7. /build/src/Interpreters/InterpreterOptimizeQuery.cpp:40: DB::InterpreterOptimizeQuery::execute() @ 0x0000000014cd71de 8. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88dc9 9. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 10. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 11. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 12. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 13. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 14. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 15. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 16. ? @ 0x00007fbc6213eac3 17. ? @ 0x00007fbc621d0850 2025.07.28 11:58:48.749686 [ 5879 ] {00ef35b7-dfc4-406e-be85-889105cd6026} executeQuery: Code: 60. DB::Exception: Table test_15.concurrent_optimize_table does not exist. (UNKNOWN_TABLE) (version 25.3.6.10636.altinitytest (altinity build)) (from [::1]:51968) (comment: 01103_optimize_drop_race_zookeeper.sh) (query 1, line 1) (in query: OPTIMIZE TABLE concurrent_optimize_table FINAL), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000a06a8eb 4. /build/src/Databases/IDatabase.cpp:41: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x0000000013dd565f 5. /build/src/Interpreters/DatabaseCatalog.cpp:442: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x00000000144f0869 6. /build/src/Interpreters/DatabaseCatalog.cpp:976: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x00000000144f6c88 7. /build/src/Interpreters/InterpreterOptimizeQuery.cpp:40: DB::InterpreterOptimizeQuery::execute() @ 0x0000000014cd71de 8. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88dc9 9. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 10. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 11. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 12. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 13. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 14. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 15. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 16. ? @ 0x00007fbc6213eac3 17. ? @ 0x00007fbc621d0850 2025.07.28 11:58:48.757947 [ 3962 ] {} test_13.rmt2 (7f9b740d-015c-470e-8cc6-8ba33be0dc63): auto DB::StorageReplicatedMergeTree::processQueueEntry(ReplicatedMergeTreeQueue::SelectedEntryPtr)::(anonymous class)::operator()(LogEntryPtr &) const: Code: 86. DB::HTTPException: Received error from remote server http://146b4357c08d:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Ftest%2F01165%2Ftest_13%2Frmt%2Freplicas%2F1&part=20250728_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.6.10636.altinitytest (altinity build)) '. (RECEIVED_ERROR_FROM_REMOTE_IO_SERVER), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.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 const&, int&&, String const&, unsigned long&&, String const&) @ 0x000000000feda8d9 4. /build/src/IO/HTTPCommon.cpp:104: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x000000000feda6e2 5. /build/src/IO/HTTPCommon.cpp:93: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x000000000feda537 6. /build/src/IO/ReadWriteBufferFromHTTP.cpp:277: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x000000001184a4c4 7. /build/src/IO/ReadWriteBufferFromHTTP.cpp:285: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x000000001184a615 8. /build/src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x000000001184ae59 9. /build/src/IO/ReadWriteBufferFromHTTP.cpp:472: void std::__function::__policy_invoker::__call_impl[abi:se190107]>(std::__function::__policy_storage const*) @ 0x000000001184cedd 10. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001184858b 11. /build/src/IO/ReadWriteBufferFromHTTP.cpp:465: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x000000001184bf0b 12. /build/src/IO/ReadBuffer.h:60: DB::ReadBuffer::next() @ 0x000000000a148c7b 13. /build/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) @ 0x0000000011849fb2 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]>&)>&, 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&) @ 0x0000000011841980 15. /build/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) @ 0x000000001621208e 16. /build/src/Storages/StorageReplicatedMergeTree.cpp:5228: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl[abi:se190107] const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000015f9a5fe 17. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000015ed8bfd 18. /build/src/Storages/StorageReplicatedMergeTree.cpp:2514: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x0000000015ec9aab 19. /build/src/Storages/StorageReplicatedMergeTree.cpp:2349: DB::StorageReplicatedMergeTree::executeLogEntry(DB::ReplicatedMergeTreeLogEntry&) @ 0x0000000015eba91b 20. /build/src/Storages/StorageReplicatedMergeTree.cpp:3876: bool std::__function::__policy_invoker&)>::__call_impl[abi:se190107])::$_1, bool (std::shared_ptr&)>>(std::__function::__policy_storage const*, std::shared_ptr&) @ 0x0000000015f9837e 21. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000165d6fc3 22. /build/src/Storages/StorageReplicatedMergeTree.cpp:3872: DB::StorageReplicatedMergeTree::processQueueEntry(std::shared_ptr) @ 0x0000000015efc18a 23. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001624c1b2 24. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000162f9c70 25. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x00000000162fa55a 26. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc6653 27. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000000fccc4c3 28. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc3d92 29. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fcca080 30. ? @ 0x00007fbc6213eac3 31. ? @ 0x00007fbc621d0850 (version 25.3.6.10636.altinitytest (altinity build)) 2025.07.28 11:58:48.764026 [ 5879 ] {} TCPHandler: Code: 60. DB::Exception: Table test_15.concurrent_optimize_table does not exist. (UNKNOWN_TABLE), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000a06a8eb 4. /build/src/Databases/IDatabase.cpp:41: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x0000000013dd565f 5. /build/src/Interpreters/DatabaseCatalog.cpp:442: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x00000000144f0869 6. /build/src/Interpreters/DatabaseCatalog.cpp:976: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x00000000144f6c88 7. /build/src/Interpreters/InterpreterOptimizeQuery.cpp:40: DB::InterpreterOptimizeQuery::execute() @ 0x0000000014cd71de 8. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88dc9 9. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 10. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 11. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 12. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 13. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 14. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 15. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 16. ? @ 0x00007fbc6213eac3 17. ? @ 0x00007fbc621d0850 2025.07.28 11:58:48.783761 [ 4900 ] {} TCPHandler: Code: 60. DB::Exception: Table test_15.concurrent_optimize_table does not exist. (UNKNOWN_TABLE), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000a06a8eb 4. /build/src/Databases/IDatabase.cpp:41: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x0000000013dd565f 5. /build/src/Interpreters/DatabaseCatalog.cpp:442: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x00000000144f0869 6. /build/src/Interpreters/DatabaseCatalog.cpp:976: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x00000000144f6c88 7. /build/src/Interpreters/InterpreterOptimizeQuery.cpp:40: DB::InterpreterOptimizeQuery::execute() @ 0x0000000014cd71de 8. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88dc9 9. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 10. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 11. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 12. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 13. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 14. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 15. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 16. ? @ 0x00007fbc6213eac3 17. ? @ 0x00007fbc621d0850 2025.07.28 11:58:48.885053 [ 3283 ] {2d25adc7-d4f1-4cb5-82de-874a753238e1} executeQuery: Code: 60. DB::Exception: Table test_15.concurrent_optimize_table does not exist. (UNKNOWN_TABLE) (version 25.3.6.10636.altinitytest (altinity build)) (from [::1]:52024) (comment: 01103_optimize_drop_race_zookeeper.sh) (query 1, line 1) (in query: INSERT INTO concurrent_optimize_table SELECT rand(1), rand(2), 1 / rand(3), toString(rand(4)), [rand(5), rand(6)], rand(7) % 2 ? NULL : generateUUIDv4(), (rand(8), rand(9)) FROM numbers(10000)), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000a06a8eb 4. /build/src/Databases/IDatabase.cpp:41: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x0000000013dd565f 5. /build/src/Interpreters/DatabaseCatalog.cpp:442: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x00000000144f0869 6. /build/src/Interpreters/DatabaseCatalog.cpp:976: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x00000000144f6c88 7. /build/src/Interpreters/InterpreterInsertQuery.cpp:169: DB::InterpreterInsertQuery::getTable(DB::ASTInsertQuery&) @ 0x000000001492bf04 8. /build/src/Interpreters/InterpreterInsertQuery.cpp:829: DB::InterpreterInsertQuery::execute() @ 0x0000000014933938 9. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88dc9 10. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 11. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 12. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 13. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 14. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 16. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 17. ? @ 0x00007fbc6213eac3 18. ? @ 0x00007fbc621d0850 2025.07.28 11:58:48.913198 [ 3283 ] {} TCPHandler: Code: 60. DB::Exception: Table test_15.concurrent_optimize_table does not exist. (UNKNOWN_TABLE), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000a06a8eb 4. /build/src/Databases/IDatabase.cpp:41: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x0000000013dd565f 5. /build/src/Interpreters/DatabaseCatalog.cpp:442: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x00000000144f0869 6. /build/src/Interpreters/DatabaseCatalog.cpp:976: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x00000000144f6c88 7. /build/src/Interpreters/InterpreterInsertQuery.cpp:169: DB::InterpreterInsertQuery::getTable(DB::ASTInsertQuery&) @ 0x000000001492bf04 8. /build/src/Interpreters/InterpreterInsertQuery.cpp:829: DB::InterpreterInsertQuery::execute() @ 0x0000000014933938 9. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88dc9 10. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 11. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 12. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 13. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 14. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 16. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 17. ? @ 0x00007fbc6213eac3 18. ? @ 0x00007fbc621d0850 2025.07.28 11:58:48.934040 [ 17232 ] {0c89d359-85df-4fe6-86bb-18a0d78d480d} executeQuery: Code: 60. DB::Exception: Table test_15.concurrent_optimize_table does not exist. (UNKNOWN_TABLE) (version 25.3.6.10636.altinitytest (altinity build)) (from [::1]:52038) (comment: 01103_optimize_drop_race_zookeeper.sh) (query 1, line 1) (in query: INSERT INTO concurrent_optimize_table SELECT rand(1), rand(2), 1 / rand(3), toString(rand(4)), [rand(5), rand(6)], rand(7) % 2 ? NULL : generateUUIDv4(), (rand(8), rand(9)) FROM numbers(10000)), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000a06a8eb 4. /build/src/Databases/IDatabase.cpp:41: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x0000000013dd565f 5. /build/src/Interpreters/DatabaseCatalog.cpp:442: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x00000000144f0869 6. /build/src/Interpreters/DatabaseCatalog.cpp:976: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x00000000144f6c88 7. /build/src/Interpreters/InterpreterInsertQuery.cpp:169: DB::InterpreterInsertQuery::getTable(DB::ASTInsertQuery&) @ 0x000000001492bf04 8. /build/src/Interpreters/InterpreterInsertQuery.cpp:829: DB::InterpreterInsertQuery::execute() @ 0x0000000014933938 9. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88dc9 10. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 11. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 12. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 13. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 14. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 16. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 17. ? @ 0x00007fbc6213eac3 18. ? @ 0x00007fbc621d0850 2025.07.28 11:58:48.948738 [ 17232 ] {} TCPHandler: Code: 60. DB::Exception: Table test_15.concurrent_optimize_table does not exist. (UNKNOWN_TABLE), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000a06a8eb 4. /build/src/Databases/IDatabase.cpp:41: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x0000000013dd565f 5. /build/src/Interpreters/DatabaseCatalog.cpp:442: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x00000000144f0869 6. /build/src/Interpreters/DatabaseCatalog.cpp:976: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x00000000144f6c88 7. /build/src/Interpreters/InterpreterInsertQuery.cpp:169: DB::InterpreterInsertQuery::getTable(DB::ASTInsertQuery&) @ 0x000000001492bf04 8. /build/src/Interpreters/InterpreterInsertQuery.cpp:829: DB::InterpreterInsertQuery::execute() @ 0x0000000014933938 9. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88dc9 10. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 11. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 12. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 13. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 14. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 16. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 17. ? @ 0x00007fbc6213eac3 18. ? @ 0x00007fbc621d0850 2025.07.28 11:58:49.017596 [ 5879 ] {03af9197-46d3-42e3-9642-7b66f83a82cb} executeQuery: Code: 60. DB::Exception: Table test_15.concurrent_optimize_table does not exist. (UNKNOWN_TABLE) (version 25.3.6.10636.altinitytest (altinity build)) (from [::1]:52042) (comment: 01103_optimize_drop_race_zookeeper.sh) (query 1, line 1) (in query: INSERT INTO concurrent_optimize_table SELECT rand(1), rand(2), 1 / rand(3), toString(rand(4)), [rand(5), rand(6)], rand(7) % 2 ? NULL : generateUUIDv4(), (rand(8), rand(9)) FROM numbers(10000)), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000a06a8eb 4. /build/src/Databases/IDatabase.cpp:41: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x0000000013dd565f 5. /build/src/Interpreters/DatabaseCatalog.cpp:442: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x00000000144f0869 6. /build/src/Interpreters/DatabaseCatalog.cpp:976: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x00000000144f6c88 7. /build/src/Interpreters/InterpreterInsertQuery.cpp:169: DB::InterpreterInsertQuery::getTable(DB::ASTInsertQuery&) @ 0x000000001492bf04 8. /build/src/Interpreters/InterpreterInsertQuery.cpp:829: DB::InterpreterInsertQuery::execute() @ 0x0000000014933938 9. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88dc9 10. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 11. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 12. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 13. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 14. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 16. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 17. ? @ 0x00007fbc6213eac3 18. ? @ 0x00007fbc621d0850 2025.07.28 11:58:49.021256 [ 17611 ] {a92d8366-48bc-4cb5-9a65-82c5feee32ce} executeQuery: Code: 60. DB::Exception: Table test_15.concurrent_optimize_table does not exist. (UNKNOWN_TABLE) (version 25.3.6.10636.altinitytest (altinity build)) (from [::1]:52030) (comment: 01103_optimize_drop_race_zookeeper.sh) (query 1, line 1) (in query: INSERT INTO concurrent_optimize_table SELECT rand(1), rand(2), 1 / rand(3), toString(rand(4)), [rand(5), rand(6)], rand(7) % 2 ? NULL : generateUUIDv4(), (rand(8), rand(9)) FROM numbers(10000)), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000a06a8eb 4. /build/src/Databases/IDatabase.cpp:41: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x0000000013dd565f 5. /build/src/Interpreters/DatabaseCatalog.cpp:442: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x00000000144f0869 6. /build/src/Interpreters/DatabaseCatalog.cpp:976: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x00000000144f6c88 7. /build/src/Interpreters/InterpreterInsertQuery.cpp:169: DB::InterpreterInsertQuery::getTable(DB::ASTInsertQuery&) @ 0x000000001492bf04 8. /build/src/Interpreters/InterpreterInsertQuery.cpp:829: DB::InterpreterInsertQuery::execute() @ 0x0000000014933938 9. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88dc9 10. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 11. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 12. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 13. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 14. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 16. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 17. ? @ 0x00007fbc6213eac3 18. ? @ 0x00007fbc621d0850 2025.07.28 11:58:49.042193 [ 5879 ] {} TCPHandler: Code: 60. DB::Exception: Table test_15.concurrent_optimize_table does not exist. (UNKNOWN_TABLE), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000a06a8eb 4. /build/src/Databases/IDatabase.cpp:41: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x0000000013dd565f 5. /build/src/Interpreters/DatabaseCatalog.cpp:442: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x00000000144f0869 6. /build/src/Interpreters/DatabaseCatalog.cpp:976: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x00000000144f6c88 7. /build/src/Interpreters/InterpreterInsertQuery.cpp:169: DB::InterpreterInsertQuery::getTable(DB::ASTInsertQuery&) @ 0x000000001492bf04 8. /build/src/Interpreters/InterpreterInsertQuery.cpp:829: DB::InterpreterInsertQuery::execute() @ 0x0000000014933938 9. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88dc9 10. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 11. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 12. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 13. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 14. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 16. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 17. ? @ 0x00007fbc6213eac3 18. ? @ 0x00007fbc621d0850 2025.07.28 11:58:49.081346 [ 17611 ] {} TCPHandler: Code: 60. DB::Exception: Table test_15.concurrent_optimize_table does not exist. (UNKNOWN_TABLE), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000a06a8eb 4. /build/src/Databases/IDatabase.cpp:41: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x0000000013dd565f 5. /build/src/Interpreters/DatabaseCatalog.cpp:442: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x00000000144f0869 6. /build/src/Interpreters/DatabaseCatalog.cpp:976: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x00000000144f6c88 7. /build/src/Interpreters/InterpreterInsertQuery.cpp:169: DB::InterpreterInsertQuery::getTable(DB::ASTInsertQuery&) @ 0x000000001492bf04 8. /build/src/Interpreters/InterpreterInsertQuery.cpp:829: DB::InterpreterInsertQuery::execute() @ 0x0000000014933938 9. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88dc9 10. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 11. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 12. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 13. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 14. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 16. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 17. ? @ 0x00007fbc6213eac3 18. ? @ 0x00007fbc621d0850 2025.07.28 11:58:49.113934 [ 17371 ] {a00061af-8448-4ba9-bb28-c0ff50013e53} executeQuery: Code: 415. DB::Exception: Cannot create a replica of the table /clickhouse/tables/01103_optimize_drop_race_zookeeper_test_15/concurrent_optimize_table, because the last replica of the table was dropped right now. (ALL_REPLICAS_LOST) (version 25.3.6.10636.altinitytest (altinity build)) (from [::1]:51940) (comment: 01103_optimize_drop_race_zookeeper.sh) (query 2, line 2) (in query: CREATE TABLE concurrent_optimize_table (`a` UInt8, `b` Int16, `c` Float32, `d` String, `e` Array(UInt8), `f` Nullable(UUID), `g` Tuple(UInt8, UInt16)) ENGINE = ReplicatedMergeTree('/clickhouse/tables/01103_optimize_drop_race_zookeeper_test_15/concurrent_optimize_table', '1') PARTITION BY b % 10 ORDER BY a SETTINGS old_parts_lifetime = 1, cleanup_delay_period = 0, cleanup_delay_period_random_add = 0, cleanup_thread_preferred_points_per_iteration = 0, index_granularity = 31489, 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 = 20868213, compact_parts_max_bytes_to_buffer = 108362629, compact_parts_max_granules_to_buffer = 1, compact_parts_merge_max_bytes_to_prefetch_part = 18898448, merge_max_block_size = 13220, prefer_fetch_merged_part_size_threshold = 1, vertical_merge_algorithm_min_rows_to_activate = 1000000, vertical_merge_algorithm_min_columns_to_activate = 76, min_merge_bytes_to_use_direct_io = 10737418240, index_granularity_bytes = 7046892, use_const_adaptive_granularity = false, 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 = true, cache_populated_by_fetch = false, marks_compress_block_size = 84392, primary_key_compress_block_size = 23861, 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. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000a9b78ab 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:1187: DB::StorageReplicatedMergeTree::createReplicaAttempt(std::shared_ptr const&, std::shared_ptr) const @ 0x0000000015ea1127 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:1087: DB::StorageReplicatedMergeTree::createReplica(std::shared_ptr const&, DB::ZooKeeperRetriesInfo const&) const @ 0x0000000015e8c7b5 6. /build/src/Storages/StorageReplicatedMergeTree.cpp:624: DB::StorageReplicatedMergeTree::StorageReplicatedMergeTree(DB::TableZnodeInfo const&, DB::LoadingStrictnessLevel, DB::StorageID const&, String const&, DB::StorageInMemoryMetadata const&, std::shared_ptr, String const&, DB::MergeTreeData::MergingParams const&, std::unique_ptr>, bool, DB::ZooKeeperRetriesInfo const&) @ 0x0000000015e8979f 7. /build/contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: std::shared_ptr std::allocate_shared[abi:se190107], DB::TableZnodeInfo&, DB::LoadingStrictnessLevel const&, DB::StorageID const&, String const&, DB::StorageInMemoryMetadata&, std::shared_ptr&, String&, DB::MergeTreeData::MergingParams&, std::unique_ptr>, bool&, DB::ZooKeeperRetriesInfo&, 0>(std::allocator const&, DB::TableZnodeInfo&, DB::LoadingStrictnessLevel const&, DB::StorageID const&, String const&, DB::StorageInMemoryMetadata&, std::shared_ptr&, String&, DB::MergeTreeData::MergingParams&, std::unique_ptr>&&, bool&, DB::ZooKeeperRetriesInfo&) @ 0x000000001663250b 8. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:851: DB::create(DB::StorageFactory::Arguments const&) @ 0x000000001662ef92 9. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000015d81ea2 10. /build/src/Interpreters/InterpreterCreateQuery.cpp:1945: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x00000000149009bb 11. /build/src/Interpreters/InterpreterCreateQuery.cpp:1743: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000148f9aa9 12. /build/src/Interpreters/InterpreterCreateQuery.cpp:2352: DB::InterpreterCreateQuery::execute() @ 0x0000000014905a41 13. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88dc9 14. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 15. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 16. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 17. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 18. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 19. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 20. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 21. ? @ 0x00007fbc6213eac3 22. ? @ 0x00007fbc621d0850 2025.07.28 11:58:49.117369 [ 7630 ] {2428b5e0-d9dd-47e9-b1eb-a437904159a9} executeQuery: Code: 60. DB::Exception: Table test_15.concurrent_optimize_table does not exist. (UNKNOWN_TABLE) (version 25.3.6.10636.altinitytest (altinity build)) (from [::1]:52048) (comment: 01103_optimize_drop_race_zookeeper.sh) (query 1, line 1) (in query: OPTIMIZE TABLE concurrent_optimize_table FINAL), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000a06a8eb 4. /build/src/Databases/IDatabase.cpp:41: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x0000000013dd565f 5. /build/src/Interpreters/DatabaseCatalog.cpp:442: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x00000000144f0869 6. /build/src/Interpreters/DatabaseCatalog.cpp:976: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x00000000144f6c88 7. /build/src/Interpreters/InterpreterOptimizeQuery.cpp:40: DB::InterpreterOptimizeQuery::execute() @ 0x0000000014cd71de 8. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88dc9 9. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 10. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 11. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 12. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 13. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 14. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 15. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 16. ? @ 0x00007fbc6213eac3 17. ? @ 0x00007fbc621d0850 2025.07.28 11:58:49.123795 [ 7630 ] {} TCPHandler: Code: 60. DB::Exception: Table test_15.concurrent_optimize_table does not exist. (UNKNOWN_TABLE), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000a06a8eb 4. /build/src/Databases/IDatabase.cpp:41: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x0000000013dd565f 5. /build/src/Interpreters/DatabaseCatalog.cpp:442: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x00000000144f0869 6. /build/src/Interpreters/DatabaseCatalog.cpp:976: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x00000000144f6c88 7. /build/src/Interpreters/InterpreterOptimizeQuery.cpp:40: DB::InterpreterOptimizeQuery::execute() @ 0x0000000014cd71de 8. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88dc9 9. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 10. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 11. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 12. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 13. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 14. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 15. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 16. ? @ 0x00007fbc6213eac3 17. ? @ 0x00007fbc621d0850 2025.07.28 11:58:49.144429 [ 17371 ] {} TCPHandler: Code: 415. DB::Exception: Cannot create a replica of the table /clickhouse/tables/01103_optimize_drop_race_zookeeper_test_15/concurrent_optimize_table, because the last replica of the table was dropped right now. (ALL_REPLICAS_LOST), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000a9b78ab 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:1187: DB::StorageReplicatedMergeTree::createReplicaAttempt(std::shared_ptr const&, std::shared_ptr) const @ 0x0000000015ea1127 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:1087: DB::StorageReplicatedMergeTree::createReplica(std::shared_ptr const&, DB::ZooKeeperRetriesInfo const&) const @ 0x0000000015e8c7b5 6. /build/src/Storages/StorageReplicatedMergeTree.cpp:624: DB::StorageReplicatedMergeTree::StorageReplicatedMergeTree(DB::TableZnodeInfo const&, DB::LoadingStrictnessLevel, DB::StorageID const&, String const&, DB::StorageInMemoryMetadata const&, std::shared_ptr, String const&, DB::MergeTreeData::MergingParams const&, std::unique_ptr>, bool, DB::ZooKeeperRetriesInfo const&) @ 0x0000000015e8979f 7. /build/contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: std::shared_ptr std::allocate_shared[abi:se190107], DB::TableZnodeInfo&, DB::LoadingStrictnessLevel const&, DB::StorageID const&, String const&, DB::StorageInMemoryMetadata&, std::shared_ptr&, String&, DB::MergeTreeData::MergingParams&, std::unique_ptr>, bool&, DB::ZooKeeperRetriesInfo&, 0>(std::allocator const&, DB::TableZnodeInfo&, DB::LoadingStrictnessLevel const&, DB::StorageID const&, String const&, DB::StorageInMemoryMetadata&, std::shared_ptr&, String&, DB::MergeTreeData::MergingParams&, std::unique_ptr>&&, bool&, DB::ZooKeeperRetriesInfo&) @ 0x000000001663250b 8. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:851: DB::create(DB::StorageFactory::Arguments const&) @ 0x000000001662ef92 9. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000015d81ea2 10. /build/src/Interpreters/InterpreterCreateQuery.cpp:1945: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x00000000149009bb 11. /build/src/Interpreters/InterpreterCreateQuery.cpp:1743: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000148f9aa9 12. /build/src/Interpreters/InterpreterCreateQuery.cpp:2352: DB::InterpreterCreateQuery::execute() @ 0x0000000014905a41 13. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88dc9 14. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 15. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 16. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 17. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 18. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 19. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 20. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 21. ? @ 0x00007fbc6213eac3 22. ? @ 0x00007fbc621d0850 2025.07.28 11:58:49.183777 [ 17232 ] {c6f85bf8-9a36-4fb0-9e3d-bfd2b3353cb8} executeQuery: Code: 60. DB::Exception: Table test_15.concurrent_optimize_table does not exist. (UNKNOWN_TABLE) (version 25.3.6.10636.altinitytest (altinity build)) (from [::1]:52060) (comment: 01103_optimize_drop_race_zookeeper.sh) (query 1, line 1) (in query: INSERT INTO concurrent_optimize_table SELECT rand(1), rand(2), 1 / rand(3), toString(rand(4)), [rand(5), rand(6)], rand(7) % 2 ? NULL : generateUUIDv4(), (rand(8), rand(9)) FROM numbers(10000)), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000a06a8eb 4. /build/src/Databases/IDatabase.cpp:41: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x0000000013dd565f 5. /build/src/Interpreters/DatabaseCatalog.cpp:442: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x00000000144f0869 6. /build/src/Interpreters/DatabaseCatalog.cpp:976: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x00000000144f6c88 7. /build/src/Interpreters/InterpreterInsertQuery.cpp:169: DB::InterpreterInsertQuery::getTable(DB::ASTInsertQuery&) @ 0x000000001492bf04 8. /build/src/Interpreters/InterpreterInsertQuery.cpp:829: DB::InterpreterInsertQuery::execute() @ 0x0000000014933938 9. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88dc9 10. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 11. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 12. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 13. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 14. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 16. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 17. ? @ 0x00007fbc6213eac3 18. ? @ 0x00007fbc621d0850 2025.07.28 11:58:49.205776 [ 17232 ] {} TCPHandler: Code: 60. DB::Exception: Table test_15.concurrent_optimize_table does not exist. (UNKNOWN_TABLE), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000a06a8eb 4. /build/src/Databases/IDatabase.cpp:41: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x0000000013dd565f 5. /build/src/Interpreters/DatabaseCatalog.cpp:442: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x00000000144f0869 6. /build/src/Interpreters/DatabaseCatalog.cpp:976: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x00000000144f6c88 7. /build/src/Interpreters/InterpreterInsertQuery.cpp:169: DB::InterpreterInsertQuery::getTable(DB::ASTInsertQuery&) @ 0x000000001492bf04 8. /build/src/Interpreters/InterpreterInsertQuery.cpp:829: DB::InterpreterInsertQuery::execute() @ 0x0000000014933938 9. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88dc9 10. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 11. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 12. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 13. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 14. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 16. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 17. ? @ 0x00007fbc6213eac3 18. ? @ 0x00007fbc621d0850 2025.07.28 11:58:49.244030 [ 17321 ] {ed808c13-ece9-47ac-ae1f-f5cd1e5c5350} executeQuery: Code: 60. DB::Exception: Table test_15.concurrent_optimize_table does not exist. (UNKNOWN_TABLE) (version 25.3.6.10636.altinitytest (altinity build)) (from [::1]:52078) (comment: 01103_optimize_drop_race_zookeeper.sh) (query 1, line 1) (in query: OPTIMIZE TABLE concurrent_optimize_table FINAL), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000a06a8eb 4. /build/src/Databases/IDatabase.cpp:41: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x0000000013dd565f 5. /build/src/Interpreters/DatabaseCatalog.cpp:442: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x00000000144f0869 6. /build/src/Interpreters/DatabaseCatalog.cpp:976: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x00000000144f6c88 7. /build/src/Interpreters/InterpreterOptimizeQuery.cpp:40: DB::InterpreterOptimizeQuery::execute() @ 0x0000000014cd71de 8. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88dc9 9. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 10. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 11. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 12. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 13. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 14. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 15. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 16. ? @ 0x00007fbc6213eac3 17. ? @ 0x00007fbc621d0850 2025.07.28 11:58:49.277344 [ 4900 ] {adcc5395-68b9-4a68-b6cb-e1c695d2f1a5} executeQuery: Code: 60. DB::Exception: Table test_15.concurrent_optimize_table does not exist. (UNKNOWN_TABLE) (version 25.3.6.10636.altinitytest (altinity build)) (from [::1]:52092) (comment: 01103_optimize_drop_race_zookeeper.sh) (query 1, line 1) (in query: OPTIMIZE TABLE concurrent_optimize_table FINAL), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000a06a8eb 4. /build/src/Databases/IDatabase.cpp:41: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x0000000013dd565f 5. /build/src/Interpreters/DatabaseCatalog.cpp:442: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x00000000144f0869 6. /build/src/Interpreters/DatabaseCatalog.cpp:976: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x00000000144f6c88 7. /build/src/Interpreters/InterpreterOptimizeQuery.cpp:40: DB::InterpreterOptimizeQuery::execute() @ 0x0000000014cd71de 8. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88dc9 9. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 10. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 11. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 12. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 13. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 14. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 15. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 16. ? @ 0x00007fbc6213eac3 17. ? @ 0x00007fbc621d0850 2025.07.28 11:58:49.277716 [ 17321 ] {} TCPHandler: Code: 60. DB::Exception: Table test_15.concurrent_optimize_table does not exist. (UNKNOWN_TABLE), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000a06a8eb 4. /build/src/Databases/IDatabase.cpp:41: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x0000000013dd565f 5. /build/src/Interpreters/DatabaseCatalog.cpp:442: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x00000000144f0869 6. /build/src/Interpreters/DatabaseCatalog.cpp:976: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x00000000144f6c88 7. /build/src/Interpreters/InterpreterOptimizeQuery.cpp:40: DB::InterpreterOptimizeQuery::execute() @ 0x0000000014cd71de 8. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88dc9 9. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 10. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 11. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 12. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 13. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 14. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 15. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 16. ? @ 0x00007fbc6213eac3 17. ? @ 0x00007fbc621d0850 2025.07.28 11:58:49.284081 [ 5879 ] {5e90a627-32a1-4b70-b103-43d9a88da336} executeQuery: Code: 60. DB::Exception: Table test_15.concurrent_optimize_table does not exist. (UNKNOWN_TABLE) (version 25.3.6.10636.altinitytest (altinity build)) (from [::1]:52074) (comment: 01103_optimize_drop_race_zookeeper.sh) (query 1, line 1) (in query: INSERT INTO concurrent_optimize_table SELECT rand(1), rand(2), 1 / rand(3), toString(rand(4)), [rand(5), rand(6)], rand(7) % 2 ? NULL : generateUUIDv4(), (rand(8), rand(9)) FROM numbers(10000)), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000a06a8eb 4. /build/src/Databases/IDatabase.cpp:41: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x0000000013dd565f 5. /build/src/Interpreters/DatabaseCatalog.cpp:442: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x00000000144f0869 6. /build/src/Interpreters/DatabaseCatalog.cpp:976: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x00000000144f6c88 7. /build/src/Interpreters/InterpreterInsertQuery.cpp:169: DB::InterpreterInsertQuery::getTable(DB::ASTInsertQuery&) @ 0x000000001492bf04 8. /build/src/Interpreters/InterpreterInsertQuery.cpp:829: DB::InterpreterInsertQuery::execute() @ 0x0000000014933938 9. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88dc9 10. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 11. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 12. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 13. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 14. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 16. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 17. ? @ 0x00007fbc6213eac3 18. ? @ 0x00007fbc621d0850 2025.07.28 11:58:49.311600 [ 4900 ] {} TCPHandler: Code: 60. DB::Exception: Table test_15.concurrent_optimize_table does not exist. (UNKNOWN_TABLE), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000a06a8eb 4. /build/src/Databases/IDatabase.cpp:41: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x0000000013dd565f 5. /build/src/Interpreters/DatabaseCatalog.cpp:442: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x00000000144f0869 6. /build/src/Interpreters/DatabaseCatalog.cpp:976: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x00000000144f6c88 7. /build/src/Interpreters/InterpreterOptimizeQuery.cpp:40: DB::InterpreterOptimizeQuery::execute() @ 0x0000000014cd71de 8. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88dc9 9. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 10. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 11. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 12. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 13. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 14. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 15. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 16. ? @ 0x00007fbc6213eac3 17. ? @ 0x00007fbc621d0850 2025.07.28 11:58:49.311687 [ 5879 ] {} TCPHandler: Code: 60. DB::Exception: Table test_15.concurrent_optimize_table does not exist. (UNKNOWN_TABLE), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000a06a8eb 4. /build/src/Databases/IDatabase.cpp:41: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x0000000013dd565f 5. /build/src/Interpreters/DatabaseCatalog.cpp:442: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x00000000144f0869 6. /build/src/Interpreters/DatabaseCatalog.cpp:976: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x00000000144f6c88 7. /build/src/Interpreters/InterpreterInsertQuery.cpp:169: DB::InterpreterInsertQuery::getTable(DB::ASTInsertQuery&) @ 0x000000001492bf04 8. /build/src/Interpreters/InterpreterInsertQuery.cpp:829: DB::InterpreterInsertQuery::execute() @ 0x0000000014933938 9. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88dc9 10. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 11. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 12. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 13. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 14. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 16. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 17. ? @ 0x00007fbc6213eac3 18. ? @ 0x00007fbc621d0850 2025.07.28 11:58:49.396692 [ 17255 ] {f7861914-f0ed-4832-b084-5216315cb289} executeQuery: Code: 60. DB::Exception: Table test_15.concurrent_optimize_table does not exist. (UNKNOWN_TABLE) (version 25.3.6.10636.altinitytest (altinity build)) (from [::1]:52118) (comment: 01103_optimize_drop_race_zookeeper.sh) (query 1, line 1) (in query: INSERT INTO concurrent_optimize_table SELECT rand(1), rand(2), 1 / rand(3), toString(rand(4)), [rand(5), rand(6)], rand(7) % 2 ? NULL : generateUUIDv4(), (rand(8), rand(9)) FROM numbers(10000)), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000a06a8eb 4. /build/src/Databases/IDatabase.cpp:41: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x0000000013dd565f 5. /build/src/Interpreters/DatabaseCatalog.cpp:442: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x00000000144f0869 6. /build/src/Interpreters/DatabaseCatalog.cpp:976: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x00000000144f6c88 7. /build/src/Interpreters/InterpreterInsertQuery.cpp:169: DB::InterpreterInsertQuery::getTable(DB::ASTInsertQuery&) @ 0x000000001492bf04 8. /build/src/Interpreters/InterpreterInsertQuery.cpp:829: DB::InterpreterInsertQuery::execute() @ 0x0000000014933938 9. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88dc9 10. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 11. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 12. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 13. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 14. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 16. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 17. ? @ 0x00007fbc6213eac3 18. ? @ 0x00007fbc621d0850 2025.07.28 11:58:49.397733 [ 17270 ] {e55841a4-6cc0-4e0d-9573-8406f8b7b7f4} executeQuery: Code: 60. DB::Exception: Table test_15.concurrent_optimize_table does not exist. (UNKNOWN_TABLE) (version 25.3.6.10636.altinitytest (altinity build)) (from [::1]:52100) (comment: 01103_optimize_drop_race_zookeeper.sh) (query 1, line 1) (in query: INSERT INTO concurrent_optimize_table SELECT rand(1), rand(2), 1 / rand(3), toString(rand(4)), [rand(5), rand(6)], rand(7) % 2 ? NULL : generateUUIDv4(), (rand(8), rand(9)) FROM numbers(10000)), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000a06a8eb 4. /build/src/Databases/IDatabase.cpp:41: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x0000000013dd565f 5. /build/src/Interpreters/DatabaseCatalog.cpp:442: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x00000000144f0869 6. /build/src/Interpreters/DatabaseCatalog.cpp:976: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x00000000144f6c88 7. /build/src/Interpreters/InterpreterInsertQuery.cpp:169: DB::InterpreterInsertQuery::getTable(DB::ASTInsertQuery&) @ 0x000000001492bf04 8. /build/src/Interpreters/InterpreterInsertQuery.cpp:829: DB::InterpreterInsertQuery::execute() @ 0x0000000014933938 9. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88dc9 10. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 11. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 12. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 13. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 14. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 16. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 17. ? @ 0x00007fbc6213eac3 18. ? @ 0x00007fbc621d0850 2025.07.28 11:58:49.416369 [ 17255 ] {} TCPHandler: Code: 60. DB::Exception: Table test_15.concurrent_optimize_table does not exist. (UNKNOWN_TABLE), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000a06a8eb 4. /build/src/Databases/IDatabase.cpp:41: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x0000000013dd565f 5. /build/src/Interpreters/DatabaseCatalog.cpp:442: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x00000000144f0869 6. /build/src/Interpreters/DatabaseCatalog.cpp:976: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x00000000144f6c88 7. /build/src/Interpreters/InterpreterInsertQuery.cpp:169: DB::InterpreterInsertQuery::getTable(DB::ASTInsertQuery&) @ 0x000000001492bf04 8. /build/src/Interpreters/InterpreterInsertQuery.cpp:829: DB::InterpreterInsertQuery::execute() @ 0x0000000014933938 9. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88dc9 10. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 11. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 12. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 13. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 14. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 16. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 17. ? @ 0x00007fbc6213eac3 18. ? @ 0x00007fbc621d0850 2025.07.28 11:58:49.430245 [ 17270 ] {} TCPHandler: Code: 60. DB::Exception: Table test_15.concurrent_optimize_table does not exist. (UNKNOWN_TABLE), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000a06a8eb 4. /build/src/Databases/IDatabase.cpp:41: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x0000000013dd565f 5. /build/src/Interpreters/DatabaseCatalog.cpp:442: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x00000000144f0869 6. /build/src/Interpreters/DatabaseCatalog.cpp:976: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x00000000144f6c88 7. /build/src/Interpreters/InterpreterInsertQuery.cpp:169: DB::InterpreterInsertQuery::getTable(DB::ASTInsertQuery&) @ 0x000000001492bf04 8. /build/src/Interpreters/InterpreterInsertQuery.cpp:829: DB::InterpreterInsertQuery::execute() @ 0x0000000014933938 9. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88dc9 10. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 11. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 12. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 13. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 14. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 16. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 17. ? @ 0x00007fbc6213eac3 18. ? @ 0x00007fbc621d0850 2025.07.28 11:58:49.452623 [ 17321 ] {b41ed22b-e75d-4c90-bd60-9fe2511bfe38} executeQuery: Code: 60. DB::Exception: Table test_15.concurrent_optimize_table does not exist. (UNKNOWN_TABLE) (version 25.3.6.10636.altinitytest (altinity build)) (from [::1]:52126) (comment: 01103_optimize_drop_race_zookeeper.sh) (query 1, line 1) (in query: INSERT INTO concurrent_optimize_table SELECT rand(1), rand(2), 1 / rand(3), toString(rand(4)), [rand(5), rand(6)], rand(7) % 2 ? NULL : generateUUIDv4(), (rand(8), rand(9)) FROM numbers(10000)), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000a06a8eb 4. /build/src/Databases/IDatabase.cpp:41: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x0000000013dd565f 5. /build/src/Interpreters/DatabaseCatalog.cpp:442: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x00000000144f0869 6. /build/src/Interpreters/DatabaseCatalog.cpp:976: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x00000000144f6c88 7. /build/src/Interpreters/InterpreterInsertQuery.cpp:169: DB::InterpreterInsertQuery::getTable(DB::ASTInsertQuery&) @ 0x000000001492bf04 8. /build/src/Interpreters/InterpreterInsertQuery.cpp:829: DB::InterpreterInsertQuery::execute() @ 0x0000000014933938 9. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88dc9 10. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 11. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 12. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 13. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 14. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 16. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 17. ? @ 0x00007fbc6213eac3 18. ? @ 0x00007fbc621d0850 2025.07.28 11:58:49.470443 [ 17321 ] {} TCPHandler: Code: 60. DB::Exception: Table test_15.concurrent_optimize_table does not exist. (UNKNOWN_TABLE), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000a06a8eb 4. /build/src/Databases/IDatabase.cpp:41: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x0000000013dd565f 5. /build/src/Interpreters/DatabaseCatalog.cpp:442: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x00000000144f0869 6. /build/src/Interpreters/DatabaseCatalog.cpp:976: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x00000000144f6c88 7. /build/src/Interpreters/InterpreterInsertQuery.cpp:169: DB::InterpreterInsertQuery::getTable(DB::ASTInsertQuery&) @ 0x000000001492bf04 8. /build/src/Interpreters/InterpreterInsertQuery.cpp:829: DB::InterpreterInsertQuery::execute() @ 0x0000000014933938 9. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88dc9 10. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 11. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 12. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 13. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 14. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 16. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 17. ? @ 0x00007fbc6213eac3 18. ? @ 0x00007fbc621d0850 2025.07.28 11:58:49.537057 [ 11826 ] {66d025f7-f1e6-4d41-8b39-77f14ed6edb4} executeQuery: Code: 60. DB::Exception: Table test_15.concurrent_optimize_table does not exist. (UNKNOWN_TABLE) (version 25.3.6.10636.altinitytest (altinity build)) (from [::1]:52144) (comment: 01103_optimize_drop_race_zookeeper.sh) (query 1, line 1) (in query: INSERT INTO concurrent_optimize_table SELECT rand(1), rand(2), 1 / rand(3), toString(rand(4)), [rand(5), rand(6)], rand(7) % 2 ? NULL : generateUUIDv4(), (rand(8), rand(9)) FROM numbers(10000)), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000a06a8eb 4. /build/src/Databases/IDatabase.cpp:41: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x0000000013dd565f 5. /build/src/Interpreters/DatabaseCatalog.cpp:442: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x00000000144f0869 6. /build/src/Interpreters/DatabaseCatalog.cpp:976: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x00000000144f6c88 7. /build/src/Interpreters/InterpreterInsertQuery.cpp:169: DB::InterpreterInsertQuery::getTable(DB::ASTInsertQuery&) @ 0x000000001492bf04 8. /build/src/Interpreters/InterpreterInsertQuery.cpp:829: DB::InterpreterInsertQuery::execute() @ 0x0000000014933938 9. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88dc9 10. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 11. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 12. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 13. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 14. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 16. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 17. ? @ 0x00007fbc6213eac3 18. ? @ 0x00007fbc621d0850 2025.07.28 11:58:49.555682 [ 11826 ] {} TCPHandler: Code: 60. DB::Exception: Table test_15.concurrent_optimize_table does not exist. (UNKNOWN_TABLE), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000a06a8eb 4. /build/src/Databases/IDatabase.cpp:41: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x0000000013dd565f 5. /build/src/Interpreters/DatabaseCatalog.cpp:442: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x00000000144f0869 6. /build/src/Interpreters/DatabaseCatalog.cpp:976: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x00000000144f6c88 7. /build/src/Interpreters/InterpreterInsertQuery.cpp:169: DB::InterpreterInsertQuery::getTable(DB::ASTInsertQuery&) @ 0x000000001492bf04 8. /build/src/Interpreters/InterpreterInsertQuery.cpp:829: DB::InterpreterInsertQuery::execute() @ 0x0000000014933938 9. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88dc9 10. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 11. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 12. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 13. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 14. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 16. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 17. ? @ 0x00007fbc6213eac3 18. ? @ 0x00007fbc621d0850 2025.07.28 11:58:49.557052 [ 4900 ] {6fb7d74e-7495-4243-b749-484697345b80} executeQuery: Code: 60. DB::Exception: Table test_15.concurrent_optimize_table does not exist. (UNKNOWN_TABLE) (version 25.3.6.10636.altinitytest (altinity build)) (from [::1]:52128) (comment: 01103_optimize_drop_race_zookeeper.sh) (query 1, line 1) (in query: OPTIMIZE TABLE concurrent_optimize_table FINAL), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000a06a8eb 4. /build/src/Databases/IDatabase.cpp:41: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x0000000013dd565f 5. /build/src/Interpreters/DatabaseCatalog.cpp:442: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x00000000144f0869 6. /build/src/Interpreters/DatabaseCatalog.cpp:976: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x00000000144f6c88 7. /build/src/Interpreters/InterpreterOptimizeQuery.cpp:40: DB::InterpreterOptimizeQuery::execute() @ 0x0000000014cd71de 8. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88dc9 9. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 10. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 11. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 12. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 13. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 14. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 15. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 16. ? @ 0x00007fbc6213eac3 17. ? @ 0x00007fbc621d0850 2025.07.28 11:58:49.593133 [ 4900 ] {} TCPHandler: Code: 60. DB::Exception: Table test_15.concurrent_optimize_table does not exist. (UNKNOWN_TABLE), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000a06a8eb 4. /build/src/Databases/IDatabase.cpp:41: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x0000000013dd565f 5. /build/src/Interpreters/DatabaseCatalog.cpp:442: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x00000000144f0869 6. /build/src/Interpreters/DatabaseCatalog.cpp:976: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x00000000144f6c88 7. /build/src/Interpreters/InterpreterOptimizeQuery.cpp:40: DB::InterpreterOptimizeQuery::execute() @ 0x0000000014cd71de 8. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88dc9 9. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 10. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 11. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 12. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 13. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 14. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 15. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 16. ? @ 0x00007fbc6213eac3 17. ? @ 0x00007fbc621d0850 2025.07.28 11:58:49.598738 [ 3960 ] {} test_13.rmt2 (7f9b740d-015c-470e-8cc6-8ba33be0dc63): auto DB::StorageReplicatedMergeTree::processQueueEntry(ReplicatedMergeTreeQueue::SelectedEntryPtr)::(anonymous class)::operator()(LogEntryPtr &) const: Code: 86. DB::HTTPException: Received error from remote server http://146b4357c08d:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Ftest%2F01165%2Ftest_13%2Frmt%2Freplicas%2F1&part=20250728_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.6.10636.altinitytest (altinity build)) '. (RECEIVED_ERROR_FROM_REMOTE_IO_SERVER), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.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 const&, int&&, String const&, unsigned long&&, String const&) @ 0x000000000feda8d9 4. /build/src/IO/HTTPCommon.cpp:104: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x000000000feda6e2 5. /build/src/IO/HTTPCommon.cpp:93: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x000000000feda537 6. /build/src/IO/ReadWriteBufferFromHTTP.cpp:277: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x000000001184a4c4 7. /build/src/IO/ReadWriteBufferFromHTTP.cpp:285: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x000000001184a615 8. /build/src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x000000001184ae59 9. /build/src/IO/ReadWriteBufferFromHTTP.cpp:472: void std::__function::__policy_invoker::__call_impl[abi:se190107]>(std::__function::__policy_storage const*) @ 0x000000001184cedd 10. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001184858b 11. /build/src/IO/ReadWriteBufferFromHTTP.cpp:465: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x000000001184bf0b 12. /build/src/IO/ReadBuffer.h:60: DB::ReadBuffer::next() @ 0x000000000a148c7b 13. /build/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) @ 0x0000000011849fb2 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]>&)>&, 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&) @ 0x0000000011841980 15. /build/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) @ 0x000000001621208e 16. /build/src/Storages/StorageReplicatedMergeTree.cpp:5228: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl[abi:se190107] const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000015f9a5fe 17. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000015ed8bfd 18. /build/src/Storages/StorageReplicatedMergeTree.cpp:2514: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x0000000015ec9aab 19. /build/src/Storages/StorageReplicatedMergeTree.cpp:2349: DB::StorageReplicatedMergeTree::executeLogEntry(DB::ReplicatedMergeTreeLogEntry&) @ 0x0000000015eba91b 20. /build/src/Storages/StorageReplicatedMergeTree.cpp:3876: bool std::__function::__policy_invoker&)>::__call_impl[abi:se190107])::$_1, bool (std::shared_ptr&)>>(std::__function::__policy_storage const*, std::shared_ptr&) @ 0x0000000015f9837e 21. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000165d6fc3 22. /build/src/Storages/StorageReplicatedMergeTree.cpp:3872: DB::StorageReplicatedMergeTree::processQueueEntry(std::shared_ptr) @ 0x0000000015efc18a 23. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001624c1b2 24. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000162f9c70 25. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x00000000162fa55a 26. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc6653 27. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000000fccc4c3 28. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc3d92 29. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fcca080 30. ? @ 0x00007fbc6213eac3 31. ? @ 0x00007fbc621d0850 (version 25.3.6.10636.altinitytest (altinity build)) 2025.07.28 11:58:49.628205 [ 17270 ] {df96c3da-9897-4f29-95c8-401043269755} executeQuery: Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01103_optimize_drop_race_zookeeper_test_15/concurrent_optimize_table/replicas/1). (TABLE_IS_READ_ONLY) (version 25.3.6.10636.altinitytest (altinity build)) (from [::1]:52164) (comment: 01103_optimize_drop_race_zookeeper.sh) (query 1, line 1) (in query: OPTIMIZE TABLE concurrent_optimize_table FINAL), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000a9b78ab 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:5935: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000015e86144 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:6112: DB::StorageReplicatedMergeTree::optimize(std::shared_ptr const&, std::shared_ptr const&, std::shared_ptr const&, bool, bool, std::vector> const&, bool, std::shared_ptr) @ 0x0000000015f21f2c 6. /build/src/Interpreters/InterpreterOptimizeQuery.cpp:84: DB::InterpreterOptimizeQuery::execute() @ 0x0000000014cd782e 7. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88dc9 8. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 9. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 10. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 11. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 12. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 13. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 14. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 15. ? @ 0x00007fbc6213eac3 16. ? @ 0x00007fbc621d0850 2025.07.28 11:58:49.667884 [ 17270 ] {} TCPHandler: Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01103_optimize_drop_race_zookeeper_test_15/concurrent_optimize_table/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000a9b78ab 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:5935: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000015e86144 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:6112: DB::StorageReplicatedMergeTree::optimize(std::shared_ptr const&, std::shared_ptr const&, std::shared_ptr const&, bool, bool, std::vector> const&, bool, std::shared_ptr) @ 0x0000000015f21f2c 6. /build/src/Interpreters/InterpreterOptimizeQuery.cpp:84: DB::InterpreterOptimizeQuery::execute() @ 0x0000000014cd782e 7. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88dc9 8. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 9. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 10. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 11. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 12. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 13. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 14. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 15. ? @ 0x00007fbc6213eac3 16. ? @ 0x00007fbc621d0850 2025.07.28 11:58:49.677879 [ 17256 ] {9747fe4f-2e86-437d-bd26-48dd4dc960e0} executeQuery: Code: 57. DB::Exception: Table test_15.concurrent_optimize_table already exists. (TABLE_ALREADY_EXISTS) (version 25.3.6.10636.altinitytest (altinity build)) (from [::1]:51642) (comment: 01103_optimize_drop_race_zookeeper.sh) (query 2, line 2) (in query: CREATE TABLE concurrent_optimize_table (`a` UInt8, `b` Int16, `c` Float32, `d` String, `e` Array(UInt8), `f` Nullable(UUID), `g` Tuple(UInt8, UInt16)) ENGINE = ReplicatedMergeTree('/clickhouse/tables/01103_optimize_drop_race_zookeeper_test_15/concurrent_optimize_table', '1') PARTITION BY b % 10 ORDER BY a SETTINGS old_parts_lifetime = 1, cleanup_delay_period = 0, cleanup_delay_period_random_add = 0, cleanup_thread_preferred_points_per_iteration = 0, index_granularity = 31489, 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 = 20868213, compact_parts_max_bytes_to_buffer = 108362629, compact_parts_max_granules_to_buffer = 1, compact_parts_merge_max_bytes_to_prefetch_part = 18898448, merge_max_block_size = 13220, prefer_fetch_merged_part_size_threshold = 1, vertical_merge_algorithm_min_rows_to_activate = 1000000, vertical_merge_algorithm_min_columns_to_activate = 76, min_merge_bytes_to_use_direct_io = 10737418240, index_granularity_bytes = 7046892, use_const_adaptive_granularity = false, 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 = true, cache_populated_by_fetch = false, marks_compress_block_size = 84392, primary_key_compress_block_size = 23861, 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. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000a06a8eb 4. /build/src/Interpreters/InterpreterCreateQuery.cpp:1824: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x0000000014901d53 5. /build/src/Interpreters/InterpreterCreateQuery.cpp:1743: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000148f9aa9 6. /build/src/Interpreters/InterpreterCreateQuery.cpp:2352: DB::InterpreterCreateQuery::execute() @ 0x0000000014905a41 7. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88dc9 8. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 9. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 10. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 11. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 12. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 13. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 14. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 15. ? @ 0x00007fbc6213eac3 16. ? @ 0x00007fbc621d0850 2025.07.28 11:58:49.692429 [ 17256 ] {} TCPHandler: Code: 57. DB::Exception: Table test_15.concurrent_optimize_table already exists. (TABLE_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000a06a8eb 4. /build/src/Interpreters/InterpreterCreateQuery.cpp:1824: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x0000000014901d53 5. /build/src/Interpreters/InterpreterCreateQuery.cpp:1743: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000148f9aa9 6. /build/src/Interpreters/InterpreterCreateQuery.cpp:2352: DB::InterpreterCreateQuery::execute() @ 0x0000000014905a41 7. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88dc9 8. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 9. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 10. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 11. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 12. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 13. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 14. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 15. ? @ 0x00007fbc6213eac3 16. ? @ 0x00007fbc621d0850 2025.07.28 11:58:49.794968 [ 4900 ] {2b7d33e3-89bd-4c31-9334-d9c5f49dc28f} executeQuery: Code: 60. DB::Exception: Table test_15.concurrent_optimize_table does not exist. (UNKNOWN_TABLE) (version 25.3.6.10636.altinitytest (altinity build)) (from [::1]:52194) (comment: 01103_optimize_drop_race_zookeeper.sh) (query 1, line 1) (in query: OPTIMIZE TABLE concurrent_optimize_table FINAL), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000a06a8eb 4. /build/src/Databases/IDatabase.cpp:41: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x0000000013dd565f 5. /build/src/Interpreters/DatabaseCatalog.cpp:442: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x00000000144f0869 6. /build/src/Interpreters/DatabaseCatalog.cpp:976: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x00000000144f6c88 7. /build/src/Interpreters/InterpreterOptimizeQuery.cpp:40: DB::InterpreterOptimizeQuery::execute() @ 0x0000000014cd71de 8. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88dc9 9. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 10. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 11. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 12. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 13. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 14. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 15. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 16. ? @ 0x00007fbc6213eac3 17. ? @ 0x00007fbc621d0850 2025.07.28 11:58:49.813394 [ 4900 ] {} TCPHandler: Code: 60. DB::Exception: Table test_15.concurrent_optimize_table does not exist. (UNKNOWN_TABLE), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000a06a8eb 4. /build/src/Databases/IDatabase.cpp:41: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x0000000013dd565f 5. /build/src/Interpreters/DatabaseCatalog.cpp:442: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x00000000144f0869 6. /build/src/Interpreters/DatabaseCatalog.cpp:976: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x00000000144f6c88 7. /build/src/Interpreters/InterpreterOptimizeQuery.cpp:40: DB::InterpreterOptimizeQuery::execute() @ 0x0000000014cd71de 8. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88dc9 9. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 10. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 11. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 12. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 13. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 14. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 15. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 16. ? @ 0x00007fbc6213eac3 17. ? @ 0x00007fbc621d0850 2025.07.28 11:58:49.816667 [ 7625 ] {260917e2-39ea-4bcf-99e8-5a25d58728e7} executeQuery: Code: 60. DB::Exception: Table test_15.concurrent_optimize_table does not exist. (UNKNOWN_TABLE) (version 25.3.6.10636.altinitytest (altinity build)) (from [::1]:52210) (comment: 01103_optimize_drop_race_zookeeper.sh) (query 1, line 1) (in query: OPTIMIZE TABLE concurrent_optimize_table FINAL), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000a06a8eb 4. /build/src/Databases/IDatabase.cpp:41: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x0000000013dd565f 5. /build/src/Interpreters/DatabaseCatalog.cpp:442: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x00000000144f0869 6. /build/src/Interpreters/DatabaseCatalog.cpp:976: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x00000000144f6c88 7. /build/src/Interpreters/InterpreterOptimizeQuery.cpp:40: DB::InterpreterOptimizeQuery::execute() @ 0x0000000014cd71de 8. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88dc9 9. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 10. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 11. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 12. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 13. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 14. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 15. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 16. ? @ 0x00007fbc6213eac3 17. ? @ 0x00007fbc621d0850 2025.07.28 11:58:49.832015 [ 7625 ] {} TCPHandler: Code: 60. DB::Exception: Table test_15.concurrent_optimize_table does not exist. (UNKNOWN_TABLE), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000a06a8eb 4. /build/src/Databases/IDatabase.cpp:41: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x0000000013dd565f 5. /build/src/Interpreters/DatabaseCatalog.cpp:442: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x00000000144f0869 6. /build/src/Interpreters/DatabaseCatalog.cpp:976: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x00000000144f6c88 7. /build/src/Interpreters/InterpreterOptimizeQuery.cpp:40: DB::InterpreterOptimizeQuery::execute() @ 0x0000000014cd71de 8. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88dc9 9. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 10. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 11. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 12. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 13. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 14. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 15. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 16. ? @ 0x00007fbc6213eac3 17. ? @ 0x00007fbc621d0850 2025.07.28 11:58:49.840356 [ 17270 ] {693f0f62-a7c9-40a9-9230-85876eabc48d} executeQuery: Code: 60. DB::Exception: Table test_15.concurrent_optimize_table does not exist. (UNKNOWN_TABLE) (version 25.3.6.10636.altinitytest (altinity build)) (from [::1]:52196) (comment: 01103_optimize_drop_race_zookeeper.sh) (query 1, line 1) (in query: INSERT INTO concurrent_optimize_table SELECT rand(1), rand(2), 1 / rand(3), toString(rand(4)), [rand(5), rand(6)], rand(7) % 2 ? NULL : generateUUIDv4(), (rand(8), rand(9)) FROM numbers(10000)), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000a06a8eb 4. /build/src/Databases/IDatabase.cpp:41: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x0000000013dd565f 5. /build/src/Interpreters/DatabaseCatalog.cpp:442: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x00000000144f0869 6. /build/src/Interpreters/DatabaseCatalog.cpp:976: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x00000000144f6c88 7. /build/src/Interpreters/InterpreterInsertQuery.cpp:169: DB::InterpreterInsertQuery::getTable(DB::ASTInsertQuery&) @ 0x000000001492bf04 8. /build/src/Interpreters/InterpreterInsertQuery.cpp:829: DB::InterpreterInsertQuery::execute() @ 0x0000000014933938 9. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88dc9 10. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 11. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 12. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 13. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 14. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 16. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 17. ? @ 0x00007fbc6213eac3 18. ? @ 0x00007fbc621d0850 2025.07.28 11:58:49.853334 [ 17270 ] {} TCPHandler: Code: 60. DB::Exception: Table test_15.concurrent_optimize_table does not exist. (UNKNOWN_TABLE), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000a06a8eb 4. /build/src/Databases/IDatabase.cpp:41: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x0000000013dd565f 5. /build/src/Interpreters/DatabaseCatalog.cpp:442: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x00000000144f0869 6. /build/src/Interpreters/DatabaseCatalog.cpp:976: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x00000000144f6c88 7. /build/src/Interpreters/InterpreterInsertQuery.cpp:169: DB::InterpreterInsertQuery::getTable(DB::ASTInsertQuery&) @ 0x000000001492bf04 8. /build/src/Interpreters/InterpreterInsertQuery.cpp:829: DB::InterpreterInsertQuery::execute() @ 0x0000000014933938 9. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88dc9 10. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 11. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 12. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 13. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 14. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 16. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 17. ? @ 0x00007fbc6213eac3 18. ? @ 0x00007fbc621d0850 2025.07.28 11:58:49.983903 [ 17287 ] {38b8f5a0-61b9-4198-b07d-1df4cc1de20d} executeQuery: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=0, jobs=0). (CANNOT_SCHEDULE_TASK) (version 25.3.6.10636.altinitytest (altinity build)) (from [::1]:51430) (comment: 01872_initial_query_start_time.sh) (query 2, line 3) (in query: select anyIf(initial_query_start_time, is_initial_query) = anyIf(initial_query_start_time, not is_initial_query), anyIf(initial_query_start_time_microseconds, is_initial_query) = anyIf(initial_query_start_time_microseconds, not is_initial_query) from system.query_log where initial_query_id = '8b7af9d26dfbe244cd160b31b09241c6' and type = 'QueryFinish';), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000fccaeeb 4. /build/src/Common/ThreadPool.cpp:275: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000fccc813 5. /build/src/Common/ThreadPool.cpp:323: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fcc7bbc 6. /build/src/Common/ThreadPool.cpp:494: ThreadPoolImpl>::scheduleOrThrowOnError(std::function, Priority) @ 0x000000000fcc7a0e 7. /build/src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::spawnThreadsImpl() @ 0x00000000169b2c0c 8. /build/src/Processors/Executors/PipelineExecutor.cpp:394: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x00000000169b0ba7 9. /build/src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x00000000169b03f4 10. /build/src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:se190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169bfeab 11. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc3d92 12. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fcca080 13. ? @ 0x00007fbc6213eac3 14. ? @ 0x00007fbc621d0850 2025.07.28 11:58:49.985852 [ 17270 ] {863e0a7c-a9de-4ae3-9e51-cd4eb31f9fd4} executeQuery: Code: 60. DB::Exception: Table test_15.concurrent_optimize_table does not exist. (UNKNOWN_TABLE) (version 25.3.6.10636.altinitytest (altinity build)) (from [::1]:52230) (comment: 01103_optimize_drop_race_zookeeper.sh) (query 1, line 1) (in query: OPTIMIZE TABLE concurrent_optimize_table FINAL), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000a06a8eb 4. /build/src/Databases/IDatabase.cpp:41: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x0000000013dd565f 5. /build/src/Interpreters/DatabaseCatalog.cpp:442: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x00000000144f0869 6. /build/src/Interpreters/DatabaseCatalog.cpp:976: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x00000000144f6c88 7. /build/src/Interpreters/InterpreterOptimizeQuery.cpp:40: DB::InterpreterOptimizeQuery::execute() @ 0x0000000014cd71de 8. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88dc9 9. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 10. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 11. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 12. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 13. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 14. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 15. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 16. ? @ 0x00007fbc6213eac3 17. ? @ 0x00007fbc621d0850 2025.07.28 11:58:49.993448 [ 17270 ] {} TCPHandler: Code: 60. DB::Exception: Table test_15.concurrent_optimize_table does not exist. (UNKNOWN_TABLE), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000a06a8eb 4. /build/src/Databases/IDatabase.cpp:41: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x0000000013dd565f 5. /build/src/Interpreters/DatabaseCatalog.cpp:442: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x00000000144f0869 6. /build/src/Interpreters/DatabaseCatalog.cpp:976: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x00000000144f6c88 7. /build/src/Interpreters/InterpreterOptimizeQuery.cpp:40: DB::InterpreterOptimizeQuery::execute() @ 0x0000000014cd71de 8. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88dc9 9. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 10. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 11. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 12. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 13. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 14. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 15. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 16. ? @ 0x00007fbc6213eac3 17. ? @ 0x00007fbc621d0850 2025.07.28 11:58:50.034417 [ 17287 ] {} 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. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000fccaeeb 4. /build/src/Common/ThreadPool.cpp:275: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000fccc813 5. /build/src/Common/ThreadPool.cpp:323: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fcc7bbc 6. /build/src/Common/ThreadPool.cpp:494: ThreadPoolImpl>::scheduleOrThrowOnError(std::function, Priority) @ 0x000000000fcc7a0e 7. /build/src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::spawnThreadsImpl() @ 0x00000000169b2c0c 8. /build/src/Processors/Executors/PipelineExecutor.cpp:394: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x00000000169b0ba7 9. /build/src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x00000000169b03f4 10. /build/src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:se190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169bfeab 11. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc3d92 12. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fcca080 13. ? @ 0x00007fbc6213eac3 14. ? @ 0x00007fbc621d0850 Job's origin stack trace: 0. /build/src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000000fc33b84 1. /build/src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000000fcc2ea7 2. /build/src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fcc535c 3. /build/src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000000fcc584d 4. /build/src/Common/ThreadPool.h:279: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x00000000169bf193 5. /build/src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x00000000169bf518 6. /build/src/Server/TCPHandler.cpp:1237: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x00000000168f1525 7. /build/src/Server/TCPHandler.cpp:678: DB::TCPHandler::runImpl() @ 0x00000000168e68e5 8. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 9. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 10. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 11. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 12. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 13. ? @ 0x00007fbc6213eac3 14. ? @ 0x00007fbc621d0850 2025.07.28 11:58:50.071641 [ 4900 ] {c596434c-efed-4f8e-9b30-795d4928f585} executeQuery: Code: 60. DB::Exception: Table test_15.concurrent_optimize_table does not exist. (UNKNOWN_TABLE) (version 25.3.6.10636.altinitytest (altinity build)) (from [::1]:52226) (comment: 01103_optimize_drop_race_zookeeper.sh) (query 1, line 1) (in query: OPTIMIZE TABLE concurrent_optimize_table FINAL), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000a06a8eb 4. /build/src/Databases/IDatabase.cpp:41: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x0000000013dd565f 5. /build/src/Interpreters/DatabaseCatalog.cpp:442: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x00000000144f0869 6. /build/src/Interpreters/DatabaseCatalog.cpp:976: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x00000000144f6c88 7. /build/src/Interpreters/InterpreterOptimizeQuery.cpp:40: DB::InterpreterOptimizeQuery::execute() @ 0x0000000014cd71de 8. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88dc9 9. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 10. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 11. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 12. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 13. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 14. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 15. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 16. ? @ 0x00007fbc6213eac3 17. ? @ 0x00007fbc621d0850 2025.07.28 11:58:50.076232 [ 4900 ] {} TCPHandler: Code: 60. DB::Exception: Table test_15.concurrent_optimize_table does not exist. (UNKNOWN_TABLE), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000a06a8eb 4. /build/src/Databases/IDatabase.cpp:41: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x0000000013dd565f 5. /build/src/Interpreters/DatabaseCatalog.cpp:442: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x00000000144f0869 6. /build/src/Interpreters/DatabaseCatalog.cpp:976: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x00000000144f6c88 7. /build/src/Interpreters/InterpreterOptimizeQuery.cpp:40: DB::InterpreterOptimizeQuery::execute() @ 0x0000000014cd71de 8. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88dc9 9. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 10. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 11. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 12. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 13. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 14. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 15. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 16. ? @ 0x00007fbc6213eac3 17. ? @ 0x00007fbc621d0850 2025.07.28 11:58:50.099131 [ 7625 ] {03951865-8daf-4619-af66-ee71193d57d7} executeQuery: Code: 60. DB::Exception: Table test_15.concurrent_optimize_table does not exist. (UNKNOWN_TABLE) (version 25.3.6.10636.altinitytest (altinity build)) (from [::1]:52236) (comment: 01103_optimize_drop_race_zookeeper.sh) (query 1, line 1) (in query: INSERT INTO concurrent_optimize_table SELECT rand(1), rand(2), 1 / rand(3), toString(rand(4)), [rand(5), rand(6)], rand(7) % 2 ? NULL : generateUUIDv4(), (rand(8), rand(9)) FROM numbers(10000)), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000a06a8eb 4. /build/src/Databases/IDatabase.cpp:41: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x0000000013dd565f 5. /build/src/Interpreters/DatabaseCatalog.cpp:442: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x00000000144f0869 6. /build/src/Interpreters/DatabaseCatalog.cpp:976: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x00000000144f6c88 7. /build/src/Interpreters/InterpreterInsertQuery.cpp:169: DB::InterpreterInsertQuery::getTable(DB::ASTInsertQuery&) @ 0x000000001492bf04 8. /build/src/Interpreters/InterpreterInsertQuery.cpp:829: DB::InterpreterInsertQuery::execute() @ 0x0000000014933938 9. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88dc9 10. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 11. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 12. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 13. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 14. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 16. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 17. ? @ 0x00007fbc6213eac3 18. ? @ 0x00007fbc621d0850 2025.07.28 11:58:50.119888 [ 7625 ] {} TCPHandler: Code: 60. DB::Exception: Table test_15.concurrent_optimize_table does not exist. (UNKNOWN_TABLE), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000a06a8eb 4. /build/src/Databases/IDatabase.cpp:41: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x0000000013dd565f 5. /build/src/Interpreters/DatabaseCatalog.cpp:442: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x00000000144f0869 6. /build/src/Interpreters/DatabaseCatalog.cpp:976: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x00000000144f6c88 7. /build/src/Interpreters/InterpreterInsertQuery.cpp:169: DB::InterpreterInsertQuery::getTable(DB::ASTInsertQuery&) @ 0x000000001492bf04 8. /build/src/Interpreters/InterpreterInsertQuery.cpp:829: DB::InterpreterInsertQuery::execute() @ 0x0000000014933938 9. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88dc9 10. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 11. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 12. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 13. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 14. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 16. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 17. ? @ 0x00007fbc6213eac3 18. ? @ 0x00007fbc621d0850 2025.07.28 11:58:50.204938 [ 3974 ] {} test_13.rmt2 (7f9b740d-015c-470e-8cc6-8ba33be0dc63): auto DB::StorageReplicatedMergeTree::processQueueEntry(ReplicatedMergeTreeQueue::SelectedEntryPtr)::(anonymous class)::operator()(LogEntryPtr &) const: Code: 86. DB::HTTPException: Received error from remote server http://146b4357c08d:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Ftest%2F01165%2Ftest_13%2Frmt%2Freplicas%2F1&part=20250728_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.6.10636.altinitytest (altinity build)) '. (RECEIVED_ERROR_FROM_REMOTE_IO_SERVER), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.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 const&, int&&, String const&, unsigned long&&, String const&) @ 0x000000000feda8d9 4. /build/src/IO/HTTPCommon.cpp:104: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x000000000feda6e2 5. /build/src/IO/HTTPCommon.cpp:93: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x000000000feda537 6. /build/src/IO/ReadWriteBufferFromHTTP.cpp:277: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x000000001184a4c4 7. /build/src/IO/ReadWriteBufferFromHTTP.cpp:285: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x000000001184a615 8. /build/src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x000000001184ae59 9. /build/src/IO/ReadWriteBufferFromHTTP.cpp:472: void std::__function::__policy_invoker::__call_impl[abi:se190107]>(std::__function::__policy_storage const*) @ 0x000000001184cedd 10. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001184858b 11. /build/src/IO/ReadWriteBufferFromHTTP.cpp:465: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x000000001184bf0b 12. /build/src/IO/ReadBuffer.h:60: DB::ReadBuffer::next() @ 0x000000000a148c7b 13. /build/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) @ 0x0000000011849fb2 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]>&)>&, 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&) @ 0x0000000011841980 15. /build/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) @ 0x000000001621208e 16. /build/src/Storages/StorageReplicatedMergeTree.cpp:5228: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl[abi:se190107] const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000015f9a5fe 17. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000015ed8bfd 18. /build/src/Storages/StorageReplicatedMergeTree.cpp:2514: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x0000000015ec9aab 19. /build/src/Storages/StorageReplicatedMergeTree.cpp:2349: DB::StorageReplicatedMergeTree::executeLogEntry(DB::ReplicatedMergeTreeLogEntry&) @ 0x0000000015eba91b 20. /build/src/Storages/StorageReplicatedMergeTree.cpp:3876: bool std::__function::__policy_invoker&)>::__call_impl[abi:se190107])::$_1, bool (std::shared_ptr&)>>(std::__function::__policy_storage const*, std::shared_ptr&) @ 0x0000000015f9837e 21. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000165d6fc3 22. /build/src/Storages/StorageReplicatedMergeTree.cpp:3872: DB::StorageReplicatedMergeTree::processQueueEntry(std::shared_ptr) @ 0x0000000015efc18a 23. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001624c1b2 24. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000162f9c70 25. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x00000000162fa55a 26. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc6653 27. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000000fccc4c3 28. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc3d92 29. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fcca080 30. ? @ 0x00007fbc6213eac3 31. ? @ 0x00007fbc621d0850 (version 25.3.6.10636.altinitytest (altinity build)) 2025.07.28 11:58:50.328924 [ 7625 ] {30a05f56-c175-4572-868f-53c3826bfb4f} executeQuery: Code: 60. DB::Exception: Table test_15.concurrent_optimize_table does not exist. (UNKNOWN_TABLE) (version 25.3.6.10636.altinitytest (altinity build)) (from [::1]:52286) (comment: 01103_optimize_drop_race_zookeeper.sh) (query 1, line 1) (in query: OPTIMIZE TABLE concurrent_optimize_table FINAL), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000a06a8eb 4. /build/src/Databases/IDatabase.cpp:41: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x0000000013dd565f 5. /build/src/Interpreters/DatabaseCatalog.cpp:442: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x00000000144f0869 6. /build/src/Interpreters/DatabaseCatalog.cpp:976: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x00000000144f6c88 7. /build/src/Interpreters/InterpreterOptimizeQuery.cpp:40: DB::InterpreterOptimizeQuery::execute() @ 0x0000000014cd71de 8. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88dc9 9. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 10. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 11. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 12. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 13. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 14. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 15. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 16. ? @ 0x00007fbc6213eac3 17. ? @ 0x00007fbc621d0850 2025.07.28 11:58:50.336469 [ 7625 ] {} TCPHandler: Code: 60. DB::Exception: Table test_15.concurrent_optimize_table does not exist. (UNKNOWN_TABLE), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000a06a8eb 4. /build/src/Databases/IDatabase.cpp:41: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x0000000013dd565f 5. /build/src/Interpreters/DatabaseCatalog.cpp:442: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x00000000144f0869 6. /build/src/Interpreters/DatabaseCatalog.cpp:976: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x00000000144f6c88 7. /build/src/Interpreters/InterpreterOptimizeQuery.cpp:40: DB::InterpreterOptimizeQuery::execute() @ 0x0000000014cd71de 8. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88dc9 9. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 10. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 11. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 12. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 13. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 14. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 15. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 16. ? @ 0x00007fbc6213eac3 17. ? @ 0x00007fbc621d0850 2025.07.28 11:58:50.345927 [ 4963 ] {f5e110b4-b0f4-4920-bdc3-9fc02a92b0c2} executeQuery: Code: 60. DB::Exception: Table test_15.concurrent_optimize_table does not exist. (UNKNOWN_TABLE) (version 25.3.6.10636.altinitytest (altinity build)) (from [::1]:52296) (comment: 01103_optimize_drop_race_zookeeper.sh) (query 1, line 1) (in query: OPTIMIZE TABLE concurrent_optimize_table FINAL), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000a06a8eb 4. /build/src/Databases/IDatabase.cpp:41: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x0000000013dd565f 5. /build/src/Interpreters/DatabaseCatalog.cpp:442: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x00000000144f0869 6. /build/src/Interpreters/DatabaseCatalog.cpp:976: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x00000000144f6c88 7. /build/src/Interpreters/InterpreterOptimizeQuery.cpp:40: DB::InterpreterOptimizeQuery::execute() @ 0x0000000014cd71de 8. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88dc9 9. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 10. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 11. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 12. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 13. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 14. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 15. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 16. ? @ 0x00007fbc6213eac3 17. ? @ 0x00007fbc621d0850 2025.07.28 11:58:50.360249 [ 17191 ] {c3abd7bc-9f5e-42d1-8cda-0c9ebe6bf708} executeQuery: Code: 60. DB::Exception: Table test_15.concurrent_optimize_table does not exist. (UNKNOWN_TABLE) (version 25.3.6.10636.altinitytest (altinity build)) (from [::1]:52306) (comment: 01103_optimize_drop_race_zookeeper.sh) (query 1, line 1) (in query: INSERT INTO concurrent_optimize_table SELECT rand(1), rand(2), 1 / rand(3), toString(rand(4)), [rand(5), rand(6)], rand(7) % 2 ? NULL : generateUUIDv4(), (rand(8), rand(9)) FROM numbers(10000)), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000a06a8eb 4. /build/src/Databases/IDatabase.cpp:41: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x0000000013dd565f 5. /build/src/Interpreters/DatabaseCatalog.cpp:442: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x00000000144f0869 6. /build/src/Interpreters/DatabaseCatalog.cpp:976: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x00000000144f6c88 7. /build/src/Interpreters/InterpreterInsertQuery.cpp:169: DB::InterpreterInsertQuery::getTable(DB::ASTInsertQuery&) @ 0x000000001492bf04 8. /build/src/Interpreters/InterpreterInsertQuery.cpp:829: DB::InterpreterInsertQuery::execute() @ 0x0000000014933938 9. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88dc9 10. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 11. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 12. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 13. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 14. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 16. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 17. ? @ 0x00007fbc6213eac3 18. ? @ 0x00007fbc621d0850 2025.07.28 11:58:50.364391 [ 4963 ] {} TCPHandler: Code: 60. DB::Exception: Table test_15.concurrent_optimize_table does not exist. (UNKNOWN_TABLE), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000a06a8eb 4. /build/src/Databases/IDatabase.cpp:41: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x0000000013dd565f 5. /build/src/Interpreters/DatabaseCatalog.cpp:442: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x00000000144f0869 6. /build/src/Interpreters/DatabaseCatalog.cpp:976: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x00000000144f6c88 7. /build/src/Interpreters/InterpreterOptimizeQuery.cpp:40: DB::InterpreterOptimizeQuery::execute() @ 0x0000000014cd71de 8. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88dc9 9. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 10. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 11. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 12. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 13. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 14. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 15. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 16. ? @ 0x00007fbc6213eac3 17. ? @ 0x00007fbc621d0850 2025.07.28 11:58:50.402213 [ 17191 ] {} TCPHandler: Code: 60. DB::Exception: Table test_15.concurrent_optimize_table does not exist. (UNKNOWN_TABLE), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000a06a8eb 4. /build/src/Databases/IDatabase.cpp:41: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x0000000013dd565f 5. /build/src/Interpreters/DatabaseCatalog.cpp:442: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x00000000144f0869 6. /build/src/Interpreters/DatabaseCatalog.cpp:976: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x00000000144f6c88 7. /build/src/Interpreters/InterpreterInsertQuery.cpp:169: DB::InterpreterInsertQuery::getTable(DB::ASTInsertQuery&) @ 0x000000001492bf04 8. /build/src/Interpreters/InterpreterInsertQuery.cpp:829: DB::InterpreterInsertQuery::execute() @ 0x0000000014933938 9. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88dc9 10. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 11. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 12. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 13. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 14. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 16. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 17. ? @ 0x00007fbc6213eac3 18. ? @ 0x00007fbc621d0850 2025.07.28 11:58:50.427168 [ 5747 ] {903d3269-9b33-47b1-b381-c8035eabc45b} executeQuery: Code: 242. DB::Exception: Table is in readonly mode due to shutdown: replica_path=/clickhouse/tables/01103_optimize_drop_race_zookeeper_test_15/concurrent_optimize_table/replicas/1. (TABLE_IS_READ_ONLY) (version 25.3.6.10636.altinitytest (altinity build)) (from [::1]:52176) (comment: 01103_optimize_drop_race_zookeeper.sh) (query 1, line 1) (in query: INSERT INTO concurrent_optimize_table SELECT rand(1), rand(2), 1 / rand(3), toString(rand(4)), [rand(5), rand(6)], rand(7) % 2 ? NULL : generateUUIDv4(), (rand(8), rand(9)) FROM numbers(10000)), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000a9b78ab 4. /build/src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:866: DB::ReplicatedMergeTreeSinkImpl::commitPart(std::shared_ptr const&, std::shared_ptr&, String const&, unsigned long)::'lambda1'()::operator()() const @ 0x000000001660eed7 5. /build/src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:1124: DB::ReplicatedMergeTreeSinkImpl::commitPart(std::shared_ptr const&, std::shared_ptr&, String const&, unsigned long)::'lambda2'()::operator()() const @ 0x000000001660d1f2 6. /build/src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:1157: void DB::ZooKeeperRetriesControl::retryLoop::commitPart(std::shared_ptr const&, std::shared_ptr&, String const&, unsigned long)::'lambda3'()&, void DB::ZooKeeperRetriesControl::retryLoop::commitPart(std::shared_ptr const&, std::shared_ptr&, String const&, unsigned long)::'lambda3'()>(DB::ReplicatedMergeTreeSinkImpl::commitPart(std::shared_ptr const&, std::shared_ptr&, String const&, unsigned long)::'lambda3'()&&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::commitPart(std::shared_ptr const&, std::shared_ptr&, String const&, unsigned long)::'lambda3'()&&, void DB::ZooKeeperRetriesControl::retryLoop::commitPart(std::shared_ptr const&, std::shared_ptr&, String const&, unsigned long)::'lambda3'()>(DB::ReplicatedMergeTreeSinkImpl::commitPart(std::shared_ptr const&, std::shared_ptr&, String const&, unsigned long)::'lambda3'()&&)::'lambda'()&&) @ 0x000000001660d07f 7. /build/src/Common/ZooKeeper/ZooKeeperRetries.h:52: DB::ReplicatedMergeTreeSinkImpl::commitPart(std::shared_ptr const&, std::shared_ptr&, String const&, unsigned long) @ 0x00000000165fd951 8. /build/src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:492: DB::ReplicatedMergeTreeSinkImpl::finishDelayedChunk(std::shared_ptr const&) @ 0x00000000165f277d 9. /build/src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:437: DB::ReplicatedMergeTreeSinkImpl::consume(DB::Chunk&) @ 0x00000000165fbd00 10. /build/src/Processors/Sinks/SinkToStorage.cpp:10: DB::SinkToStorage::onConsume(DB::Chunk) @ 0x0000000016cee093 11. /build/src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: void std::__function::__policy_invoker::__call_impl[abi:se190107]>(std::__function::__policy_storage const*) @ 0x0000000016c0ad89 12. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000016c0abf5 13. /build/src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: DB::ExceptionKeepingTransform::work() @ 0x0000000016c0a6fe 14. /build/src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x00000000169bd00f 15. /build/src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x00000000169b2105 16. /build/src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeSingleThread(unsigned long) @ 0x00000000169b23be 17. /build/src/Processors/Executors/PipelineExecutor.cpp:416: void std::__function::__policy_invoker::__call_impl[abi:se190107]>(std::__function::__policy_storage const*) @ 0x00000000169b2e3f 18. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc6653 19. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000000fccc4c3 20. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc3d92 21. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fcca080 22. ? @ 0x00007fbc6213eac3 23. ? @ 0x00007fbc621d0850 2025.07.28 11:58:50.429560 [ 17321 ] {8fabe52e-7c75-4b8e-8900-0373d5b3a985} executeQuery: Code: 242. DB::Exception: Table is in readonly mode due to shutdown: replica_path=/clickhouse/tables/01103_optimize_drop_race_zookeeper_test_15/concurrent_optimize_table/replicas/1. (TABLE_IS_READ_ONLY) (version 25.3.6.10636.altinitytest (altinity build)) (from [::1]:52154) (comment: 01103_optimize_drop_race_zookeeper.sh) (query 1, line 1) (in query: INSERT INTO concurrent_optimize_table SELECT rand(1), rand(2), 1 / rand(3), toString(rand(4)), [rand(5), rand(6)], rand(7) % 2 ? NULL : generateUUIDv4(), (rand(8), rand(9)) FROM numbers(10000)), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000a9b78ab 4. /build/src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:866: DB::ReplicatedMergeTreeSinkImpl::commitPart(std::shared_ptr const&, std::shared_ptr&, String const&, unsigned long)::'lambda1'()::operator()() const @ 0x000000001660eed7 5. /build/src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:1124: DB::ReplicatedMergeTreeSinkImpl::commitPart(std::shared_ptr const&, std::shared_ptr&, String const&, unsigned long)::'lambda2'()::operator()() const @ 0x000000001660d1f2 6. /build/src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:1157: void DB::ZooKeeperRetriesControl::retryLoop::commitPart(std::shared_ptr const&, std::shared_ptr&, String const&, unsigned long)::'lambda3'()&, void DB::ZooKeeperRetriesControl::retryLoop::commitPart(std::shared_ptr const&, std::shared_ptr&, String const&, unsigned long)::'lambda3'()>(DB::ReplicatedMergeTreeSinkImpl::commitPart(std::shared_ptr const&, std::shared_ptr&, String const&, unsigned long)::'lambda3'()&&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::commitPart(std::shared_ptr const&, std::shared_ptr&, String const&, unsigned long)::'lambda3'()&&, void DB::ZooKeeperRetriesControl::retryLoop::commitPart(std::shared_ptr const&, std::shared_ptr&, String const&, unsigned long)::'lambda3'()>(DB::ReplicatedMergeTreeSinkImpl::commitPart(std::shared_ptr const&, std::shared_ptr&, String const&, unsigned long)::'lambda3'()&&)::'lambda'()&&) @ 0x000000001660d07f 7. /build/src/Common/ZooKeeper/ZooKeeperRetries.h:52: DB::ReplicatedMergeTreeSinkImpl::commitPart(std::shared_ptr const&, std::shared_ptr&, String const&, unsigned long) @ 0x00000000165fd951 8. /build/src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:492: DB::ReplicatedMergeTreeSinkImpl::finishDelayedChunk(std::shared_ptr const&) @ 0x00000000165f277d 9. /build/src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:437: DB::ReplicatedMergeTreeSinkImpl::consume(DB::Chunk&) @ 0x00000000165fbd00 10. /build/src/Processors/Sinks/SinkToStorage.cpp:10: DB::SinkToStorage::onConsume(DB::Chunk) @ 0x0000000016cee093 11. /build/src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: void std::__function::__policy_invoker::__call_impl[abi:se190107]>(std::__function::__policy_storage const*) @ 0x0000000016c0ad89 12. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000016c0abf5 13. /build/src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: DB::ExceptionKeepingTransform::work() @ 0x0000000016c0a6fe 14. /build/src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x00000000169bd00f 15. /build/src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x00000000169b2105 16. /build/src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeSingleThread(unsigned long) @ 0x00000000169b23be 17. /build/src/Processors/Executors/PipelineExecutor.cpp:416: void std::__function::__policy_invoker::__call_impl[abi:se190107]>(std::__function::__policy_storage const*) @ 0x00000000169b2e3f 18. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc6653 19. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000000fccc4c3 20. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc3d92 21. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fcca080 22. ? @ 0x00007fbc6213eac3 23. ? @ 0x00007fbc621d0850 2025.07.28 11:58:50.432522 [ 5327 ] {558e0b45-92b9-4cc5-8c9e-743fbc5c58f8} executeQuery: Code: 253. DB::Exception: Replica /clickhouse/tables/01103_optimize_drop_race_zookeeper_test_15/concurrent_optimize_table/replicas/1 already exists. (REPLICA_ALREADY_EXISTS) (version 25.3.6.10636.altinitytest (altinity build)) (from [::1]:52246) (comment: 01103_optimize_drop_race_zookeeper.sh) (query 2, line 2) (in query: CREATE TABLE concurrent_optimize_table (`a` UInt8, `b` Int16, `c` Float32, `d` String, `e` Array(UInt8), `f` Nullable(UUID), `g` Tuple(UInt8, UInt16)) ENGINE = ReplicatedMergeTree('/clickhouse/tables/01103_optimize_drop_race_zookeeper_test_15/concurrent_optimize_table', '1') PARTITION BY b % 10 ORDER BY a SETTINGS old_parts_lifetime = 1, cleanup_delay_period = 0, cleanup_delay_period_random_add = 0, cleanup_thread_preferred_points_per_iteration = 0, index_granularity = 31489, 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 = 20868213, compact_parts_max_bytes_to_buffer = 108362629, compact_parts_max_granules_to_buffer = 1, compact_parts_merge_max_bytes_to_prefetch_part = 18898448, merge_max_block_size = 13220, prefer_fetch_merged_part_size_threshold = 1, vertical_merge_algorithm_min_rows_to_activate = 1000000, vertical_merge_algorithm_min_columns_to_activate = 76, min_merge_bytes_to_use_direct_io = 10737418240, index_granularity_bytes = 7046892, use_const_adaptive_granularity = false, 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 = true, cache_populated_by_fetch = false, marks_compress_block_size = 84392, primary_key_compress_block_size = 23861, 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. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000a9b78ab 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:1237: DB::StorageReplicatedMergeTree::createReplicaAttempt(std::shared_ptr const&, std::shared_ptr) const @ 0x0000000015ea1634 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:1087: DB::StorageReplicatedMergeTree::createReplica(std::shared_ptr const&, DB::ZooKeeperRetriesInfo const&) const @ 0x0000000015e8c7b5 6. /build/src/Storages/StorageReplicatedMergeTree.cpp:624: DB::StorageReplicatedMergeTree::StorageReplicatedMergeTree(DB::TableZnodeInfo const&, DB::LoadingStrictnessLevel, DB::StorageID const&, String const&, DB::StorageInMemoryMetadata const&, std::shared_ptr, String const&, DB::MergeTreeData::MergingParams const&, std::unique_ptr>, bool, DB::ZooKeeperRetriesInfo const&) @ 0x0000000015e8979f 7. /build/contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: std::shared_ptr std::allocate_shared[abi:se190107], DB::TableZnodeInfo&, DB::LoadingStrictnessLevel const&, DB::StorageID const&, String const&, DB::StorageInMemoryMetadata&, std::shared_ptr&, String&, DB::MergeTreeData::MergingParams&, std::unique_ptr>, bool&, DB::ZooKeeperRetriesInfo&, 0>(std::allocator const&, DB::TableZnodeInfo&, DB::LoadingStrictnessLevel const&, DB::StorageID const&, String const&, DB::StorageInMemoryMetadata&, std::shared_ptr&, String&, DB::MergeTreeData::MergingParams&, std::unique_ptr>&&, bool&, DB::ZooKeeperRetriesInfo&) @ 0x000000001663250b 8. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:851: DB::create(DB::StorageFactory::Arguments const&) @ 0x000000001662ef92 9. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000015d81ea2 10. /build/src/Interpreters/InterpreterCreateQuery.cpp:1945: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x00000000149009bb 11. /build/src/Interpreters/InterpreterCreateQuery.cpp:1743: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000148f9aa9 12. /build/src/Interpreters/InterpreterCreateQuery.cpp:2352: DB::InterpreterCreateQuery::execute() @ 0x0000000014905a41 13. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88dc9 14. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 15. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 16. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 17. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 18. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 19. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 20. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 21. ? @ 0x00007fbc6213eac3 22. ? @ 0x00007fbc621d0850 2025.07.28 11:58:50.450712 [ 17255 ] {038319b1-ce17-4b81-9b10-3af79b0e6697} executeQuery: Code: 242. DB::Exception: Table is in readonly mode due to shutdown: replica_path=/clickhouse/tables/01103_optimize_drop_race_zookeeper_test_15/concurrent_optimize_table/replicas/1. (TABLE_IS_READ_ONLY) (version 25.3.6.10636.altinitytest (altinity build)) (from [::1]:52190) (comment: 01103_optimize_drop_race_zookeeper.sh) (query 1, line 1) (in query: INSERT INTO concurrent_optimize_table SELECT rand(1), rand(2), 1 / rand(3), toString(rand(4)), [rand(5), rand(6)], rand(7) % 2 ? NULL : generateUUIDv4(), (rand(8), rand(9)) FROM numbers(10000)), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000a9b78ab 4. /build/src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:866: DB::ReplicatedMergeTreeSinkImpl::commitPart(std::shared_ptr const&, std::shared_ptr&, String const&, unsigned long)::'lambda1'()::operator()() const @ 0x000000001660eed7 5. /build/src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:1124: DB::ReplicatedMergeTreeSinkImpl::commitPart(std::shared_ptr const&, std::shared_ptr&, String const&, unsigned long)::'lambda2'()::operator()() const @ 0x000000001660d1f2 6. /build/src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:1157: void DB::ZooKeeperRetriesControl::retryLoop::commitPart(std::shared_ptr const&, std::shared_ptr&, String const&, unsigned long)::'lambda3'()&, void DB::ZooKeeperRetriesControl::retryLoop::commitPart(std::shared_ptr const&, std::shared_ptr&, String const&, unsigned long)::'lambda3'()>(DB::ReplicatedMergeTreeSinkImpl::commitPart(std::shared_ptr const&, std::shared_ptr&, String const&, unsigned long)::'lambda3'()&&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::commitPart(std::shared_ptr const&, std::shared_ptr&, String const&, unsigned long)::'lambda3'()&&, void DB::ZooKeeperRetriesControl::retryLoop::commitPart(std::shared_ptr const&, std::shared_ptr&, String const&, unsigned long)::'lambda3'()>(DB::ReplicatedMergeTreeSinkImpl::commitPart(std::shared_ptr const&, std::shared_ptr&, String const&, unsigned long)::'lambda3'()&&)::'lambda'()&&) @ 0x000000001660d07f 7. /build/src/Common/ZooKeeper/ZooKeeperRetries.h:52: DB::ReplicatedMergeTreeSinkImpl::commitPart(std::shared_ptr const&, std::shared_ptr&, String const&, unsigned long) @ 0x00000000165fd951 8. /build/src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:492: DB::ReplicatedMergeTreeSinkImpl::finishDelayedChunk(std::shared_ptr const&) @ 0x00000000165f277d 9. /build/src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:437: DB::ReplicatedMergeTreeSinkImpl::consume(DB::Chunk&) @ 0x00000000165fbd00 10. /build/src/Processors/Sinks/SinkToStorage.cpp:10: DB::SinkToStorage::onConsume(DB::Chunk) @ 0x0000000016cee093 11. /build/src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: void std::__function::__policy_invoker::__call_impl[abi:se190107]>(std::__function::__policy_storage const*) @ 0x0000000016c0ad89 12. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000016c0abf5 13. /build/src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: DB::ExceptionKeepingTransform::work() @ 0x0000000016c0a6fe 14. /build/src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x00000000169bd00f 15. /build/src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x00000000169b2105 16. /build/src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeSingleThread(unsigned long) @ 0x00000000169b23be 17. /build/src/Processors/Executors/PipelineExecutor.cpp:416: void std::__function::__policy_invoker::__call_impl[abi:se190107]>(std::__function::__policy_storage const*) @ 0x00000000169b2e3f 18. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc6653 19. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000000fccc4c3 20. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc3d92 21. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fcca080 22. ? @ 0x00007fbc6213eac3 23. ? @ 0x00007fbc621d0850 2025.07.28 11:58:50.456644 [ 5747 ] {} TCPHandler: Code: 242. DB::Exception: Table is in readonly mode due to shutdown: replica_path=/clickhouse/tables/01103_optimize_drop_race_zookeeper_test_15/concurrent_optimize_table/replicas/1. (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000a9b78ab 4. /build/src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:866: DB::ReplicatedMergeTreeSinkImpl::commitPart(std::shared_ptr const&, std::shared_ptr&, String const&, unsigned long)::'lambda1'()::operator()() const @ 0x000000001660eed7 5. /build/src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:1124: DB::ReplicatedMergeTreeSinkImpl::commitPart(std::shared_ptr const&, std::shared_ptr&, String const&, unsigned long)::'lambda2'()::operator()() const @ 0x000000001660d1f2 6. /build/src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:1157: void DB::ZooKeeperRetriesControl::retryLoop::commitPart(std::shared_ptr const&, std::shared_ptr&, String const&, unsigned long)::'lambda3'()&, void DB::ZooKeeperRetriesControl::retryLoop::commitPart(std::shared_ptr const&, std::shared_ptr&, String const&, unsigned long)::'lambda3'()>(DB::ReplicatedMergeTreeSinkImpl::commitPart(std::shared_ptr const&, std::shared_ptr&, String const&, unsigned long)::'lambda3'()&&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::commitPart(std::shared_ptr const&, std::shared_ptr&, String const&, unsigned long)::'lambda3'()&&, void DB::ZooKeeperRetriesControl::retryLoop::commitPart(std::shared_ptr const&, std::shared_ptr&, String const&, unsigned long)::'lambda3'()>(DB::ReplicatedMergeTreeSinkImpl::commitPart(std::shared_ptr const&, std::shared_ptr&, String const&, unsigned long)::'lambda3'()&&)::'lambda'()&&) @ 0x000000001660d07f 7. /build/src/Common/ZooKeeper/ZooKeeperRetries.h:52: DB::ReplicatedMergeTreeSinkImpl::commitPart(std::shared_ptr const&, std::shared_ptr&, String const&, unsigned long) @ 0x00000000165fd951 8. /build/src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:492: DB::ReplicatedMergeTreeSinkImpl::finishDelayedChunk(std::shared_ptr const&) @ 0x00000000165f277d 9. /build/src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:437: DB::ReplicatedMergeTreeSinkImpl::consume(DB::Chunk&) @ 0x00000000165fbd00 10. /build/src/Processors/Sinks/SinkToStorage.cpp:10: DB::SinkToStorage::onConsume(DB::Chunk) @ 0x0000000016cee093 11. /build/src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: void std::__function::__policy_invoker::__call_impl[abi:se190107]>(std::__function::__policy_storage const*) @ 0x0000000016c0ad89 12. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000016c0abf5 13. /build/src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: DB::ExceptionKeepingTransform::work() @ 0x0000000016c0a6fe 14. /build/src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x00000000169bd00f 15. /build/src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x00000000169b2105 16. /build/src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeSingleThread(unsigned long) @ 0x00000000169b23be 17. /build/src/Processors/Executors/PipelineExecutor.cpp:416: void std::__function::__policy_invoker::__call_impl[abi:se190107]>(std::__function::__policy_storage const*) @ 0x00000000169b2e3f 18. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc6653 19. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000000fccc4c3 20. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc3d92 21. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fcca080 22. ? @ 0x00007fbc6213eac3 23. ? @ 0x00007fbc621d0850 Job's origin stack trace: 0. /build/src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000000fc33b84 1. /build/src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000000fcc2ea7 2. /build/src/Common/ThreadPool.cpp:401: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fcc7f1c 3. /build/src/Common/ThreadPool.cpp:494: ThreadPoolImpl>::scheduleOrThrowOnError(std::function, Priority) @ 0x000000000fcc7a0e 4. /build/src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::spawnThreadsImpl() @ 0x00000000169b2c0c 5. /build/src/Processors/Executors/PipelineExecutor.cpp:394: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x00000000169b0ba7 6. /build/src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x00000000169b03f4 7. /build/src/Processors/Executors/CompletedPipelineExecutor.cpp:42: void std::__function::__policy_invoker::__call_impl[abi:se190107]::ThreadFromGlobalPoolImpl(DB::CompletedPipelineExecutor::execute()::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169af7e1 8. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc3d92 9. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fcca080 10. ? @ 0x00007fbc6213eac3 11. ? @ 0x00007fbc621d0850 Job's origin stack trace: 0. /build/src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000000fc33b84 1. /build/src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000000fcc2ea7 2. /build/src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fcc535c 3. /build/src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000000fcc584d 4. /build/src/Common/ThreadPool.h:279: DB::CompletedPipelineExecutor::execute() @ 0x00000000169af267 5. /build/src/Server/TCPHandler.cpp:707: DB::TCPHandler::runImpl() @ 0x00000000168e6b2e 6. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 7. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 8. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 9. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 10. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 11. ? @ 0x00007fbc6213eac3 12. ? @ 0x00007fbc621d0850 2025.07.28 11:58:50.463789 [ 5327 ] {} TCPHandler: Code: 253. DB::Exception: Replica /clickhouse/tables/01103_optimize_drop_race_zookeeper_test_15/concurrent_optimize_table/replicas/1 already exists. (REPLICA_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000a9b78ab 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:1237: DB::StorageReplicatedMergeTree::createReplicaAttempt(std::shared_ptr const&, std::shared_ptr) const @ 0x0000000015ea1634 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:1087: DB::StorageReplicatedMergeTree::createReplica(std::shared_ptr const&, DB::ZooKeeperRetriesInfo const&) const @ 0x0000000015e8c7b5 6. /build/src/Storages/StorageReplicatedMergeTree.cpp:624: DB::StorageReplicatedMergeTree::StorageReplicatedMergeTree(DB::TableZnodeInfo const&, DB::LoadingStrictnessLevel, DB::StorageID const&, String const&, DB::StorageInMemoryMetadata const&, std::shared_ptr, String const&, DB::MergeTreeData::MergingParams const&, std::unique_ptr>, bool, DB::ZooKeeperRetriesInfo const&) @ 0x0000000015e8979f 7. /build/contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: std::shared_ptr std::allocate_shared[abi:se190107], DB::TableZnodeInfo&, DB::LoadingStrictnessLevel const&, DB::StorageID const&, String const&, DB::StorageInMemoryMetadata&, std::shared_ptr&, String&, DB::MergeTreeData::MergingParams&, std::unique_ptr>, bool&, DB::ZooKeeperRetriesInfo&, 0>(std::allocator const&, DB::TableZnodeInfo&, DB::LoadingStrictnessLevel const&, DB::StorageID const&, String const&, DB::StorageInMemoryMetadata&, std::shared_ptr&, String&, DB::MergeTreeData::MergingParams&, std::unique_ptr>&&, bool&, DB::ZooKeeperRetriesInfo&) @ 0x000000001663250b 8. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:851: DB::create(DB::StorageFactory::Arguments const&) @ 0x000000001662ef92 9. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000015d81ea2 10. /build/src/Interpreters/InterpreterCreateQuery.cpp:1945: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x00000000149009bb 11. /build/src/Interpreters/InterpreterCreateQuery.cpp:1743: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000148f9aa9 12. /build/src/Interpreters/InterpreterCreateQuery.cpp:2352: DB::InterpreterCreateQuery::execute() @ 0x0000000014905a41 13. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88dc9 14. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 15. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 16. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 17. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 18. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 19. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 20. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 21. ? @ 0x00007fbc6213eac3 22. ? @ 0x00007fbc621d0850 2025.07.28 11:58:50.480747 [ 17321 ] {} TCPHandler: Code: 242. DB::Exception: Table is in readonly mode due to shutdown: replica_path=/clickhouse/tables/01103_optimize_drop_race_zookeeper_test_15/concurrent_optimize_table/replicas/1. (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000a9b78ab 4. /build/src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:866: DB::ReplicatedMergeTreeSinkImpl::commitPart(std::shared_ptr const&, std::shared_ptr&, String const&, unsigned long)::'lambda1'()::operator()() const @ 0x000000001660eed7 5. /build/src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:1124: DB::ReplicatedMergeTreeSinkImpl::commitPart(std::shared_ptr const&, std::shared_ptr&, String const&, unsigned long)::'lambda2'()::operator()() const @ 0x000000001660d1f2 6. /build/src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:1157: void DB::ZooKeeperRetriesControl::retryLoop::commitPart(std::shared_ptr const&, std::shared_ptr&, String const&, unsigned long)::'lambda3'()&, void DB::ZooKeeperRetriesControl::retryLoop::commitPart(std::shared_ptr const&, std::shared_ptr&, String const&, unsigned long)::'lambda3'()>(DB::ReplicatedMergeTreeSinkImpl::commitPart(std::shared_ptr const&, std::shared_ptr&, String const&, unsigned long)::'lambda3'()&&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::commitPart(std::shared_ptr const&, std::shared_ptr&, String const&, unsigned long)::'lambda3'()&&, void DB::ZooKeeperRetriesControl::retryLoop::commitPart(std::shared_ptr const&, std::shared_ptr&, String const&, unsigned long)::'lambda3'()>(DB::ReplicatedMergeTreeSinkImpl::commitPart(std::shared_ptr const&, std::shared_ptr&, String const&, unsigned long)::'lambda3'()&&)::'lambda'()&&) @ 0x000000001660d07f 7. /build/src/Common/ZooKeeper/ZooKeeperRetries.h:52: DB::ReplicatedMergeTreeSinkImpl::commitPart(std::shared_ptr const&, std::shared_ptr&, String const&, unsigned long) @ 0x00000000165fd951 8. /build/src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:492: DB::ReplicatedMergeTreeSinkImpl::finishDelayedChunk(std::shared_ptr const&) @ 0x00000000165f277d 9. /build/src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:437: DB::ReplicatedMergeTreeSinkImpl::consume(DB::Chunk&) @ 0x00000000165fbd00 10. /build/src/Processors/Sinks/SinkToStorage.cpp:10: DB::SinkToStorage::onConsume(DB::Chunk) @ 0x0000000016cee093 11. /build/src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: void std::__function::__policy_invoker::__call_impl[abi:se190107]>(std::__function::__policy_storage const*) @ 0x0000000016c0ad89 12. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000016c0abf5 13. /build/src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: DB::ExceptionKeepingTransform::work() @ 0x0000000016c0a6fe 14. /build/src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x00000000169bd00f 15. /build/src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x00000000169b2105 16. /build/src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeSingleThread(unsigned long) @ 0x00000000169b23be 17. /build/src/Processors/Executors/PipelineExecutor.cpp:416: void std::__function::__policy_invoker::__call_impl[abi:se190107]>(std::__function::__policy_storage const*) @ 0x00000000169b2e3f 18. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc6653 19. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000000fccc4c3 20. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc3d92 21. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fcca080 22. ? @ 0x00007fbc6213eac3 23. ? @ 0x00007fbc621d0850 Job's origin stack trace: 0. /build/src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000000fc33b84 1. /build/src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000000fcc2ea7 2. /build/src/Common/ThreadPool.cpp:401: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fcc7f1c 3. /build/src/Common/ThreadPool.cpp:494: ThreadPoolImpl>::scheduleOrThrowOnError(std::function, Priority) @ 0x000000000fcc7a0e 4. /build/src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::spawnThreadsImpl() @ 0x00000000169b2c0c 5. /build/src/Processors/Executors/PipelineExecutor.cpp:394: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x00000000169b0ba7 6. /build/src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x00000000169b03f4 7. /build/src/Processors/Executors/CompletedPipelineExecutor.cpp:42: void std::__function::__policy_invoker::__call_impl[abi:se190107]::ThreadFromGlobalPoolImpl(DB::CompletedPipelineExecutor::execute()::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169af7e1 8. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc3d92 9. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fcca080 10. ? @ 0x00007fbc6213eac3 11. ? @ 0x00007fbc621d0850 Job's origin stack trace: 0. /build/src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000000fc33b84 1. /build/src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000000fcc2ea7 2. /build/src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fcc535c 3. /build/src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000000fcc584d 4. /build/src/Common/ThreadPool.h:279: DB::CompletedPipelineExecutor::execute() @ 0x00000000169af267 5. /build/src/Server/TCPHandler.cpp:707: DB::TCPHandler::runImpl() @ 0x00000000168e6b2e 6. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 7. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 8. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 9. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 10. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 11. ? @ 0x00007fbc6213eac3 12. ? @ 0x00007fbc621d0850 2025.07.28 11:58:50.502607 [ 17255 ] {} TCPHandler: Code: 242. DB::Exception: Table is in readonly mode due to shutdown: replica_path=/clickhouse/tables/01103_optimize_drop_race_zookeeper_test_15/concurrent_optimize_table/replicas/1. (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000a9b78ab 4. /build/src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:866: DB::ReplicatedMergeTreeSinkImpl::commitPart(std::shared_ptr const&, std::shared_ptr&, String const&, unsigned long)::'lambda1'()::operator()() const @ 0x000000001660eed7 5. /build/src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:1124: DB::ReplicatedMergeTreeSinkImpl::commitPart(std::shared_ptr const&, std::shared_ptr&, String const&, unsigned long)::'lambda2'()::operator()() const @ 0x000000001660d1f2 6. /build/src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:1157: void DB::ZooKeeperRetriesControl::retryLoop::commitPart(std::shared_ptr const&, std::shared_ptr&, String const&, unsigned long)::'lambda3'()&, void DB::ZooKeeperRetriesControl::retryLoop::commitPart(std::shared_ptr const&, std::shared_ptr&, String const&, unsigned long)::'lambda3'()>(DB::ReplicatedMergeTreeSinkImpl::commitPart(std::shared_ptr const&, std::shared_ptr&, String const&, unsigned long)::'lambda3'()&&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::commitPart(std::shared_ptr const&, std::shared_ptr&, String const&, unsigned long)::'lambda3'()&&, void DB::ZooKeeperRetriesControl::retryLoop::commitPart(std::shared_ptr const&, std::shared_ptr&, String const&, unsigned long)::'lambda3'()>(DB::ReplicatedMergeTreeSinkImpl::commitPart(std::shared_ptr const&, std::shared_ptr&, String const&, unsigned long)::'lambda3'()&&)::'lambda'()&&) @ 0x000000001660d07f 7. /build/src/Common/ZooKeeper/ZooKeeperRetries.h:52: DB::ReplicatedMergeTreeSinkImpl::commitPart(std::shared_ptr const&, std::shared_ptr&, String const&, unsigned long) @ 0x00000000165fd951 8. /build/src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:492: DB::ReplicatedMergeTreeSinkImpl::finishDelayedChunk(std::shared_ptr const&) @ 0x00000000165f277d 9. /build/src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:437: DB::ReplicatedMergeTreeSinkImpl::consume(DB::Chunk&) @ 0x00000000165fbd00 10. /build/src/Processors/Sinks/SinkToStorage.cpp:10: DB::SinkToStorage::onConsume(DB::Chunk) @ 0x0000000016cee093 11. /build/src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: void std::__function::__policy_invoker::__call_impl[abi:se190107]>(std::__function::__policy_storage const*) @ 0x0000000016c0ad89 12. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000016c0abf5 13. /build/src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: DB::ExceptionKeepingTransform::work() @ 0x0000000016c0a6fe 14. /build/src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x00000000169bd00f 15. /build/src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x00000000169b2105 16. /build/src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeSingleThread(unsigned long) @ 0x00000000169b23be 17. /build/src/Processors/Executors/PipelineExecutor.cpp:416: void std::__function::__policy_invoker::__call_impl[abi:se190107]>(std::__function::__policy_storage const*) @ 0x00000000169b2e3f 18. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc6653 19. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000000fccc4c3 20. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc3d92 21. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fcca080 22. ? @ 0x00007fbc6213eac3 23. ? @ 0x00007fbc621d0850 Job's origin stack trace: 0. /build/src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000000fc33b84 1. /build/src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000000fcc2ea7 2. /build/src/Common/ThreadPool.cpp:401: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fcc7f1c 3. /build/src/Common/ThreadPool.cpp:494: ThreadPoolImpl>::scheduleOrThrowOnError(std::function, Priority) @ 0x000000000fcc7a0e 4. /build/src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::spawnThreadsImpl() @ 0x00000000169b2c0c 5. /build/src/Processors/Executors/PipelineExecutor.cpp:394: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x00000000169b0ba7 6. /build/src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x00000000169b03f4 7. /build/src/Processors/Executors/CompletedPipelineExecutor.cpp:42: void std::__function::__policy_invoker::__call_impl[abi:se190107]::ThreadFromGlobalPoolImpl(DB::CompletedPipelineExecutor::execute()::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169af7e1 8. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc3d92 9. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fcca080 10. ? @ 0x00007fbc6213eac3 11. ? @ 0x00007fbc621d0850 Job's origin stack trace: 0. /build/src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000000fc33b84 1. /build/src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000000fcc2ea7 2. /build/src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fcc535c 3. /build/src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000000fcc584d 4. /build/src/Common/ThreadPool.h:279: DB::CompletedPipelineExecutor::execute() @ 0x00000000169af267 5. /build/src/Server/TCPHandler.cpp:707: DB::TCPHandler::runImpl() @ 0x00000000168e6b2e 6. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 7. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 8. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 9. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 10. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 11. ? @ 0x00007fbc6213eac3 12. ? @ 0x00007fbc621d0850 2025.07.28 11:58:50.543744 [ 3976 ] {} test_13.rmt2 (7f9b740d-015c-470e-8cc6-8ba33be0dc63): auto DB::StorageReplicatedMergeTree::processQueueEntry(ReplicatedMergeTreeQueue::SelectedEntryPtr)::(anonymous class)::operator()(LogEntryPtr &) const: Code: 86. DB::HTTPException: Received error from remote server http://146b4357c08d:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Ftest%2F01165%2Ftest_13%2Frmt%2Freplicas%2F1&part=20250728_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.6.10636.altinitytest (altinity build)) '. (RECEIVED_ERROR_FROM_REMOTE_IO_SERVER), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.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 const&, int&&, String const&, unsigned long&&, String const&) @ 0x000000000feda8d9 4. /build/src/IO/HTTPCommon.cpp:104: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x000000000feda6e2 5. /build/src/IO/HTTPCommon.cpp:93: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x000000000feda537 6. /build/src/IO/ReadWriteBufferFromHTTP.cpp:277: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x000000001184a4c4 7. /build/src/IO/ReadWriteBufferFromHTTP.cpp:285: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x000000001184a615 8. /build/src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x000000001184ae59 9. /build/src/IO/ReadWriteBufferFromHTTP.cpp:472: void std::__function::__policy_invoker::__call_impl[abi:se190107]>(std::__function::__policy_storage const*) @ 0x000000001184cedd 10. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001184858b 11. /build/src/IO/ReadWriteBufferFromHTTP.cpp:465: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x000000001184bf0b 12. /build/src/IO/ReadBuffer.h:60: DB::ReadBuffer::next() @ 0x000000000a148c7b 13. /build/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) @ 0x0000000011849fb2 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]>&)>&, 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&) @ 0x0000000011841980 15. /build/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) @ 0x000000001621208e 16. /build/src/Storages/StorageReplicatedMergeTree.cpp:5228: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl[abi:se190107] const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000015f9a5fe 17. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000015ed8bfd 18. /build/src/Storages/StorageReplicatedMergeTree.cpp:2514: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x0000000015ec9aab 19. /build/src/Storages/StorageReplicatedMergeTree.cpp:2349: DB::StorageReplicatedMergeTree::executeLogEntry(DB::ReplicatedMergeTreeLogEntry&) @ 0x0000000015eba91b 20. /build/src/Storages/StorageReplicatedMergeTree.cpp:3876: bool std::__function::__policy_invoker&)>::__call_impl[abi:se190107])::$_1, bool (std::shared_ptr&)>>(std::__function::__policy_storage const*, std::shared_ptr&) @ 0x0000000015f9837e 21. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000165d6fc3 22. /build/src/Storages/StorageReplicatedMergeTree.cpp:3872: DB::StorageReplicatedMergeTree::processQueueEntry(std::shared_ptr) @ 0x0000000015efc18a 23. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001624c1b2 24. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000162f9c70 25. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x00000000162fa55a 26. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc6653 27. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000000fccc4c3 28. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc3d92 29. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fcca080 30. ? @ 0x00007fbc6213eac3 31. ? @ 0x00007fbc621d0850 (version 25.3.6.10636.altinitytest (altinity build)) 2025.07.28 11:58:50.577185 [ 7625 ] {47719d94-cb12-4ebf-9405-6b90883b244b} executeQuery: Code: 60. DB::Exception: Table test_15.concurrent_optimize_table does not exist. (UNKNOWN_TABLE) (version 25.3.6.10636.altinitytest (altinity build)) (from [::1]:52338) (comment: 01103_optimize_drop_race_zookeeper.sh) (query 1, line 1) (in query: OPTIMIZE TABLE concurrent_optimize_table FINAL), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000a06a8eb 4. /build/src/Databases/IDatabase.cpp:41: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x0000000013dd565f 5. /build/src/Interpreters/DatabaseCatalog.cpp:442: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x00000000144f0869 6. /build/src/Interpreters/DatabaseCatalog.cpp:976: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x00000000144f6c88 7. /build/src/Interpreters/InterpreterOptimizeQuery.cpp:40: DB::InterpreterOptimizeQuery::execute() @ 0x0000000014cd71de 8. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88dc9 9. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 10. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 11. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 12. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 13. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 14. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 15. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 16. ? @ 0x00007fbc6213eac3 17. ? @ 0x00007fbc621d0850 2025.07.28 11:58:50.582746 [ 7625 ] {} TCPHandler: Code: 60. DB::Exception: Table test_15.concurrent_optimize_table does not exist. (UNKNOWN_TABLE), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000a06a8eb 4. /build/src/Databases/IDatabase.cpp:41: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x0000000013dd565f 5. /build/src/Interpreters/DatabaseCatalog.cpp:442: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x00000000144f0869 6. /build/src/Interpreters/DatabaseCatalog.cpp:976: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x00000000144f6c88 7. /build/src/Interpreters/InterpreterOptimizeQuery.cpp:40: DB::InterpreterOptimizeQuery::execute() @ 0x0000000014cd71de 8. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88dc9 9. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 10. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 11. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 12. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 13. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 14. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 15. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 16. ? @ 0x00007fbc6213eac3 17. ? @ 0x00007fbc621d0850 2025.07.28 11:58:50.644074 [ 17321 ] {3ce30c93-2eeb-4bc9-abf2-12876e10808a} executeQuery: Code: 60. DB::Exception: Table test_15.concurrent_optimize_table does not exist. (UNKNOWN_TABLE) (version 25.3.6.10636.altinitytest (altinity build)) (from [::1]:52348) (comment: 01103_optimize_drop_race_zookeeper.sh) (query 1, line 1) (in query: INSERT INTO concurrent_optimize_table SELECT rand(1), rand(2), 1 / rand(3), toString(rand(4)), [rand(5), rand(6)], rand(7) % 2 ? NULL : generateUUIDv4(), (rand(8), rand(9)) FROM numbers(10000)), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000a06a8eb 4. /build/src/Databases/IDatabase.cpp:41: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x0000000013dd565f 5. /build/src/Interpreters/DatabaseCatalog.cpp:442: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x00000000144f0869 6. /build/src/Interpreters/DatabaseCatalog.cpp:976: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x00000000144f6c88 7. /build/src/Interpreters/InterpreterInsertQuery.cpp:169: DB::InterpreterInsertQuery::getTable(DB::ASTInsertQuery&) @ 0x000000001492bf04 8. /build/src/Interpreters/InterpreterInsertQuery.cpp:829: DB::InterpreterInsertQuery::execute() @ 0x0000000014933938 9. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88dc9 10. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 11. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 12. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 13. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 14. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 16. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 17. ? @ 0x00007fbc6213eac3 18. ? @ 0x00007fbc621d0850 2025.07.28 11:58:50.652022 [ 17321 ] {} TCPHandler: Code: 60. DB::Exception: Table test_15.concurrent_optimize_table does not exist. (UNKNOWN_TABLE), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000a06a8eb 4. /build/src/Databases/IDatabase.cpp:41: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x0000000013dd565f 5. /build/src/Interpreters/DatabaseCatalog.cpp:442: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x00000000144f0869 6. /build/src/Interpreters/DatabaseCatalog.cpp:976: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x00000000144f6c88 7. /build/src/Interpreters/InterpreterInsertQuery.cpp:169: DB::InterpreterInsertQuery::getTable(DB::ASTInsertQuery&) @ 0x000000001492bf04 8. /build/src/Interpreters/InterpreterInsertQuery.cpp:829: DB::InterpreterInsertQuery::execute() @ 0x0000000014933938 9. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88dc9 10. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 11. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 12. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 13. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 14. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 16. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 17. ? @ 0x00007fbc6213eac3 18. ? @ 0x00007fbc621d0850 2025.07.28 11:58:50.676538 [ 5951 ] {111fe3e0-d48d-4381-a3e5-4da977632fb8} executeQuery: Code: 253. DB::Exception: Replica /clickhouse/tables/01103_optimize_drop_race_zookeeper_test_15/concurrent_optimize_table/replicas/1 already exists. (REPLICA_ALREADY_EXISTS) (version 25.3.6.10636.altinitytest (altinity build)) (from [::1]:52294) (comment: 01103_optimize_drop_race_zookeeper.sh) (query 2, line 2) (in query: CREATE TABLE concurrent_optimize_table (`a` UInt8, `b` Int16, `c` Float32, `d` String, `e` Array(UInt8), `f` Nullable(UUID), `g` Tuple(UInt8, UInt16)) ENGINE = ReplicatedMergeTree('/clickhouse/tables/01103_optimize_drop_race_zookeeper_test_15/concurrent_optimize_table', '1') PARTITION BY b % 10 ORDER BY a SETTINGS old_parts_lifetime = 1, cleanup_delay_period = 0, cleanup_delay_period_random_add = 0, cleanup_thread_preferred_points_per_iteration = 0, index_granularity = 31489, 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 = 20868213, compact_parts_max_bytes_to_buffer = 108362629, compact_parts_max_granules_to_buffer = 1, compact_parts_merge_max_bytes_to_prefetch_part = 18898448, merge_max_block_size = 13220, prefer_fetch_merged_part_size_threshold = 1, vertical_merge_algorithm_min_rows_to_activate = 1000000, vertical_merge_algorithm_min_columns_to_activate = 76, min_merge_bytes_to_use_direct_io = 10737418240, index_granularity_bytes = 7046892, use_const_adaptive_granularity = false, 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 = true, cache_populated_by_fetch = false, marks_compress_block_size = 84392, primary_key_compress_block_size = 23861, 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. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000a9b78ab 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:1237: DB::StorageReplicatedMergeTree::createReplicaAttempt(std::shared_ptr const&, std::shared_ptr) const @ 0x0000000015ea1634 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:1087: DB::StorageReplicatedMergeTree::createReplica(std::shared_ptr const&, DB::ZooKeeperRetriesInfo const&) const @ 0x0000000015e8c7b5 6. /build/src/Storages/StorageReplicatedMergeTree.cpp:624: DB::StorageReplicatedMergeTree::StorageReplicatedMergeTree(DB::TableZnodeInfo const&, DB::LoadingStrictnessLevel, DB::StorageID const&, String const&, DB::StorageInMemoryMetadata const&, std::shared_ptr, String const&, DB::MergeTreeData::MergingParams const&, std::unique_ptr>, bool, DB::ZooKeeperRetriesInfo const&) @ 0x0000000015e8979f 7. /build/contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: std::shared_ptr std::allocate_shared[abi:se190107], DB::TableZnodeInfo&, DB::LoadingStrictnessLevel const&, DB::StorageID const&, String const&, DB::StorageInMemoryMetadata&, std::shared_ptr&, String&, DB::MergeTreeData::MergingParams&, std::unique_ptr>, bool&, DB::ZooKeeperRetriesInfo&, 0>(std::allocator const&, DB::TableZnodeInfo&, DB::LoadingStrictnessLevel const&, DB::StorageID const&, String const&, DB::StorageInMemoryMetadata&, std::shared_ptr&, String&, DB::MergeTreeData::MergingParams&, std::unique_ptr>&&, bool&, DB::ZooKeeperRetriesInfo&) @ 0x000000001663250b 8. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:851: DB::create(DB::StorageFactory::Arguments const&) @ 0x000000001662ef92 9. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000015d81ea2 10. /build/src/Interpreters/InterpreterCreateQuery.cpp:1945: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x00000000149009bb 11. /build/src/Interpreters/InterpreterCreateQuery.cpp:1743: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000148f9aa9 12. /build/src/Interpreters/InterpreterCreateQuery.cpp:2352: DB::InterpreterCreateQuery::execute() @ 0x0000000014905a41 13. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88dc9 14. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 15. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 16. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 17. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 18. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 19. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 20. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 21. ? @ 0x00007fbc6213eac3 22. ? @ 0x00007fbc621d0850 2025.07.28 11:58:50.692024 [ 5951 ] {} TCPHandler: Code: 253. DB::Exception: Replica /clickhouse/tables/01103_optimize_drop_race_zookeeper_test_15/concurrent_optimize_table/replicas/1 already exists. (REPLICA_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000a9b78ab 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:1237: DB::StorageReplicatedMergeTree::createReplicaAttempt(std::shared_ptr const&, std::shared_ptr) const @ 0x0000000015ea1634 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:1087: DB::StorageReplicatedMergeTree::createReplica(std::shared_ptr const&, DB::ZooKeeperRetriesInfo const&) const @ 0x0000000015e8c7b5 6. /build/src/Storages/StorageReplicatedMergeTree.cpp:624: DB::StorageReplicatedMergeTree::StorageReplicatedMergeTree(DB::TableZnodeInfo const&, DB::LoadingStrictnessLevel, DB::StorageID const&, String const&, DB::StorageInMemoryMetadata const&, std::shared_ptr, String const&, DB::MergeTreeData::MergingParams const&, std::unique_ptr>, bool, DB::ZooKeeperRetriesInfo const&) @ 0x0000000015e8979f 7. /build/contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: std::shared_ptr std::allocate_shared[abi:se190107], DB::TableZnodeInfo&, DB::LoadingStrictnessLevel const&, DB::StorageID const&, String const&, DB::StorageInMemoryMetadata&, std::shared_ptr&, String&, DB::MergeTreeData::MergingParams&, std::unique_ptr>, bool&, DB::ZooKeeperRetriesInfo&, 0>(std::allocator const&, DB::TableZnodeInfo&, DB::LoadingStrictnessLevel const&, DB::StorageID const&, String const&, DB::StorageInMemoryMetadata&, std::shared_ptr&, String&, DB::MergeTreeData::MergingParams&, std::unique_ptr>&&, bool&, DB::ZooKeeperRetriesInfo&) @ 0x000000001663250b 8. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:851: DB::create(DB::StorageFactory::Arguments const&) @ 0x000000001662ef92 9. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000015d81ea2 10. /build/src/Interpreters/InterpreterCreateQuery.cpp:1945: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x00000000149009bb 11. /build/src/Interpreters/InterpreterCreateQuery.cpp:1743: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000148f9aa9 12. /build/src/Interpreters/InterpreterCreateQuery.cpp:2352: DB::InterpreterCreateQuery::execute() @ 0x0000000014905a41 13. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88dc9 14. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 15. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 16. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 17. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 18. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 19. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 20. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 21. ? @ 0x00007fbc6213eac3 22. ? @ 0x00007fbc621d0850 2025.07.28 11:58:50.715148 [ 5747 ] {76e2c767-66b2-42f1-a319-e584a61ec671} executeQuery: Code: 60. DB::Exception: Table test_15.concurrent_optimize_table does not exist. (UNKNOWN_TABLE) (version 25.3.6.10636.altinitytest (altinity build)) (from [::1]:52360) (comment: 01103_optimize_drop_race_zookeeper.sh) (query 1, line 1) (in query: INSERT INTO concurrent_optimize_table SELECT rand(1), rand(2), 1 / rand(3), toString(rand(4)), [rand(5), rand(6)], rand(7) % 2 ? NULL : generateUUIDv4(), (rand(8), rand(9)) FROM numbers(10000)), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000a06a8eb 4. /build/src/Databases/IDatabase.cpp:41: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x0000000013dd565f 5. /build/src/Interpreters/DatabaseCatalog.cpp:442: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x00000000144f0869 6. /build/src/Interpreters/DatabaseCatalog.cpp:976: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x00000000144f6c88 7. /build/src/Interpreters/InterpreterInsertQuery.cpp:169: DB::InterpreterInsertQuery::getTable(DB::ASTInsertQuery&) @ 0x000000001492bf04 8. /build/src/Interpreters/InterpreterInsertQuery.cpp:829: DB::InterpreterInsertQuery::execute() @ 0x0000000014933938 9. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88dc9 10. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 11. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 12. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 13. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 14. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 16. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 17. ? @ 0x00007fbc6213eac3 18. ? @ 0x00007fbc621d0850 2025.07.28 11:58:50.724704 [ 5747 ] {} TCPHandler: Code: 60. DB::Exception: Table test_15.concurrent_optimize_table does not exist. (UNKNOWN_TABLE), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000a06a8eb 4. /build/src/Databases/IDatabase.cpp:41: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x0000000013dd565f 5. /build/src/Interpreters/DatabaseCatalog.cpp:442: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x00000000144f0869 6. /build/src/Interpreters/DatabaseCatalog.cpp:976: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x00000000144f6c88 7. /build/src/Interpreters/InterpreterInsertQuery.cpp:169: DB::InterpreterInsertQuery::getTable(DB::ASTInsertQuery&) @ 0x000000001492bf04 8. /build/src/Interpreters/InterpreterInsertQuery.cpp:829: DB::InterpreterInsertQuery::execute() @ 0x0000000014933938 9. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88dc9 10. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 11. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 12. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 13. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 14. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 16. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 17. ? @ 0x00007fbc6213eac3 18. ? @ 0x00007fbc621d0850 2025.07.28 11:58:50.751512 [ 4963 ] {326301dc-922f-4ccf-8f39-1a0efac97d0e} executeQuery: Code: 60. DB::Exception: Table test_15.concurrent_optimize_table does not exist. (UNKNOWN_TABLE) (version 25.3.6.10636.altinitytest (altinity build)) (from [::1]:52398) (comment: 01103_optimize_drop_race_zookeeper.sh) (query 1, line 1) (in query: INSERT INTO concurrent_optimize_table SELECT rand(1), rand(2), 1 / rand(3), toString(rand(4)), [rand(5), rand(6)], rand(7) % 2 ? NULL : generateUUIDv4(), (rand(8), rand(9)) FROM numbers(10000)), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000a06a8eb 4. /build/src/Databases/IDatabase.cpp:41: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x0000000013dd565f 5. /build/src/Interpreters/DatabaseCatalog.cpp:442: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x00000000144f0869 6. /build/src/Interpreters/DatabaseCatalog.cpp:976: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x00000000144f6c88 7. /build/src/Interpreters/InterpreterInsertQuery.cpp:169: DB::InterpreterInsertQuery::getTable(DB::ASTInsertQuery&) @ 0x000000001492bf04 8. /build/src/Interpreters/InterpreterInsertQuery.cpp:829: DB::InterpreterInsertQuery::execute() @ 0x0000000014933938 9. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88dc9 10. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 11. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 12. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 13. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 14. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 16. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 17. ? @ 0x00007fbc6213eac3 18. ? @ 0x00007fbc621d0850 2025.07.28 11:58:50.751551 [ 17191 ] {f7bde165-4df6-4094-8e9c-dae98581fabb} executeQuery: Code: 60. DB::Exception: Table test_15.concurrent_optimize_table does not exist. (UNKNOWN_TABLE) (version 25.3.6.10636.altinitytest (altinity build)) (from [::1]:52414) (comment: 01103_optimize_drop_race_zookeeper.sh) (query 1, line 1) (in query: OPTIMIZE TABLE concurrent_optimize_table FINAL), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000a06a8eb 4. /build/src/Databases/IDatabase.cpp:41: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x0000000013dd565f 5. /build/src/Interpreters/DatabaseCatalog.cpp:442: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x00000000144f0869 6. /build/src/Interpreters/DatabaseCatalog.cpp:976: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x00000000144f6c88 7. /build/src/Interpreters/InterpreterOptimizeQuery.cpp:40: DB::InterpreterOptimizeQuery::execute() @ 0x0000000014cd71de 8. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88dc9 9. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 10. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 11. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 12. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 13. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 14. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 15. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 16. ? @ 0x00007fbc6213eac3 17. ? @ 0x00007fbc621d0850 2025.07.28 11:58:50.769297 [ 4963 ] {} TCPHandler: Code: 60. DB::Exception: Table test_15.concurrent_optimize_table does not exist. (UNKNOWN_TABLE), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000a06a8eb 4. /build/src/Databases/IDatabase.cpp:41: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x0000000013dd565f 5. /build/src/Interpreters/DatabaseCatalog.cpp:442: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x00000000144f0869 6. /build/src/Interpreters/DatabaseCatalog.cpp:976: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x00000000144f6c88 7. /build/src/Interpreters/InterpreterInsertQuery.cpp:169: DB::InterpreterInsertQuery::getTable(DB::ASTInsertQuery&) @ 0x000000001492bf04 8. /build/src/Interpreters/InterpreterInsertQuery.cpp:829: DB::InterpreterInsertQuery::execute() @ 0x0000000014933938 9. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88dc9 10. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 11. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 12. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 13. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 14. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 16. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 17. ? @ 0x00007fbc6213eac3 18. ? @ 0x00007fbc621d0850 2025.07.28 11:58:50.781193 [ 17191 ] {} TCPHandler: Code: 60. DB::Exception: Table test_15.concurrent_optimize_table does not exist. (UNKNOWN_TABLE), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000a06a8eb 4. /build/src/Databases/IDatabase.cpp:41: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x0000000013dd565f 5. /build/src/Interpreters/DatabaseCatalog.cpp:442: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x00000000144f0869 6. /build/src/Interpreters/DatabaseCatalog.cpp:976: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x00000000144f6c88 7. /build/src/Interpreters/InterpreterOptimizeQuery.cpp:40: DB::InterpreterOptimizeQuery::execute() @ 0x0000000014cd71de 8. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88dc9 9. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 10. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 11. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 12. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 13. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 14. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 15. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 16. ? @ 0x00007fbc6213eac3 17. ? @ 0x00007fbc621d0850 2025.07.28 11:58:50.781918 [ 5327 ] {af7f1976-bc6e-443f-b15f-6817e1bc6ac2} executeQuery: Code: 60. DB::Exception: Table test_15.concurrent_optimize_table does not exist. (UNKNOWN_TABLE) (version 25.3.6.10636.altinitytest (altinity build)) (from [::1]:52386) (comment: 01103_optimize_drop_race_zookeeper.sh) (query 1, line 1) (in query: INSERT INTO concurrent_optimize_table SELECT rand(1), rand(2), 1 / rand(3), toString(rand(4)), [rand(5), rand(6)], rand(7) % 2 ? NULL : generateUUIDv4(), (rand(8), rand(9)) FROM numbers(10000)), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000a06a8eb 4. /build/src/Databases/IDatabase.cpp:41: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x0000000013dd565f 5. /build/src/Interpreters/DatabaseCatalog.cpp:442: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x00000000144f0869 6. /build/src/Interpreters/DatabaseCatalog.cpp:976: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x00000000144f6c88 7. /build/src/Interpreters/InterpreterInsertQuery.cpp:169: DB::InterpreterInsertQuery::getTable(DB::ASTInsertQuery&) @ 0x000000001492bf04 8. /build/src/Interpreters/InterpreterInsertQuery.cpp:829: DB::InterpreterInsertQuery::execute() @ 0x0000000014933938 9. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88dc9 10. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 11. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 12. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 13. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 14. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 16. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 17. ? @ 0x00007fbc6213eac3 18. ? @ 0x00007fbc621d0850 2025.07.28 11:58:50.808959 [ 5327 ] {} TCPHandler: Code: 60. DB::Exception: Table test_15.concurrent_optimize_table does not exist. (UNKNOWN_TABLE), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000a06a8eb 4. /build/src/Databases/IDatabase.cpp:41: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x0000000013dd565f 5. /build/src/Interpreters/DatabaseCatalog.cpp:442: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x00000000144f0869 6. /build/src/Interpreters/DatabaseCatalog.cpp:976: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x00000000144f6c88 7. /build/src/Interpreters/InterpreterInsertQuery.cpp:169: DB::InterpreterInsertQuery::getTable(DB::ASTInsertQuery&) @ 0x000000001492bf04 8. /build/src/Interpreters/InterpreterInsertQuery.cpp:829: DB::InterpreterInsertQuery::execute() @ 0x0000000014933938 9. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88dc9 10. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 11. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 12. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 13. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 14. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 16. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 17. ? @ 0x00007fbc6213eac3 18. ? @ 0x00007fbc621d0850 2025.07.28 11:58:50.952330 [ 17203 ] {83163c20-6c8d-4f4f-8065-e8007d2e97a1} executeQuery: Code: 60. DB::Exception: Table test_15.concurrent_optimize_table does not exist. (UNKNOWN_TABLE) (version 25.3.6.10636.altinitytest (altinity build)) (from [::1]:52422) (comment: 01103_optimize_drop_race_zookeeper.sh) (query 1, line 1) (in query: OPTIMIZE TABLE concurrent_optimize_table FINAL), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000a06a8eb 4. /build/src/Databases/IDatabase.cpp:41: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x0000000013dd565f 5. /build/src/Interpreters/DatabaseCatalog.cpp:442: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x00000000144f0869 6. /build/src/Interpreters/DatabaseCatalog.cpp:976: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x00000000144f6c88 7. /build/src/Interpreters/InterpreterOptimizeQuery.cpp:40: DB::InterpreterOptimizeQuery::execute() @ 0x0000000014cd71de 8. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88dc9 9. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 10. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 11. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 12. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 13. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 14. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 15. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 16. ? @ 0x00007fbc6213eac3 17. ? @ 0x00007fbc621d0850 2025.07.28 11:58:50.983366 [ 17270 ] {4c434698-2029-4c52-ae31-4d2f4f218f28} test_15.concurrent_optimize_table (113a053f-deb2-4203-9936-78900aecf5ef): Removing leftovers from table /clickhouse/tables/01103_optimize_drop_race_zookeeper_test_15/concurrent_optimize_table (this might take several minutes) 2025.07.28 11:58:50.984045 [ 17203 ] {} TCPHandler: Code: 60. DB::Exception: Table test_15.concurrent_optimize_table does not exist. (UNKNOWN_TABLE), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000a06a8eb 4. /build/src/Databases/IDatabase.cpp:41: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x0000000013dd565f 5. /build/src/Interpreters/DatabaseCatalog.cpp:442: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x00000000144f0869 6. /build/src/Interpreters/DatabaseCatalog.cpp:976: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x00000000144f6c88 7. /build/src/Interpreters/InterpreterOptimizeQuery.cpp:40: DB::InterpreterOptimizeQuery::execute() @ 0x0000000014cd71de 8. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88dc9 9. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 10. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 11. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 12. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 13. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 14. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 15. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 16. ? @ 0x00007fbc6213eac3 17. ? @ 0x00007fbc621d0850 2025.07.28 11:58:50.985250 [ 4581 ] {eea9167b-0d77-4564-bf9e-a1f0ee881cd2} executeQuery: Code: 60. DB::Exception: Table test_15.concurrent_optimize_table does not exist. (UNKNOWN_TABLE) (version 25.3.6.10636.altinitytest (altinity build)) (from [::1]:52436) (comment: 01103_optimize_drop_race_zookeeper.sh) (query 1, line 1) (in query: INSERT INTO concurrent_optimize_table SELECT rand(1), rand(2), 1 / rand(3), toString(rand(4)), [rand(5), rand(6)], rand(7) % 2 ? NULL : generateUUIDv4(), (rand(8), rand(9)) FROM numbers(10000)), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000a06a8eb 4. /build/src/Databases/IDatabase.cpp:41: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x0000000013dd565f 5. /build/src/Interpreters/DatabaseCatalog.cpp:442: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x00000000144f0869 6. /build/src/Interpreters/DatabaseCatalog.cpp:976: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x00000000144f6c88 7. /build/src/Interpreters/InterpreterInsertQuery.cpp:169: DB::InterpreterInsertQuery::getTable(DB::ASTInsertQuery&) @ 0x000000001492bf04 8. /build/src/Interpreters/InterpreterInsertQuery.cpp:829: DB::InterpreterInsertQuery::execute() @ 0x0000000014933938 9. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88dc9 10. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 11. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 12. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 13. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 14. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 16. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 17. ? @ 0x00007fbc6213eac3 18. ? @ 0x00007fbc621d0850 2025.07.28 11:58:51.001496 [ 4581 ] {} TCPHandler: Code: 60. DB::Exception: Table test_15.concurrent_optimize_table does not exist. (UNKNOWN_TABLE), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000a06a8eb 4. /build/src/Databases/IDatabase.cpp:41: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x0000000013dd565f 5. /build/src/Interpreters/DatabaseCatalog.cpp:442: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x00000000144f0869 6. /build/src/Interpreters/DatabaseCatalog.cpp:976: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x00000000144f6c88 7. /build/src/Interpreters/InterpreterInsertQuery.cpp:169: DB::InterpreterInsertQuery::getTable(DB::ASTInsertQuery&) @ 0x000000001492bf04 8. /build/src/Interpreters/InterpreterInsertQuery.cpp:829: DB::InterpreterInsertQuery::execute() @ 0x0000000014933938 9. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88dc9 10. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 11. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 12. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 13. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 14. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 16. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 17. ? @ 0x00007fbc6213eac3 18. ? @ 0x00007fbc621d0850 2025.07.28 11:58:51.037120 [ 4446 ] {6a7ba757-a33c-40b2-baad-109bf44b2730} executeQuery: Code: 60. DB::Exception: Table test_15.concurrent_optimize_table does not exist. (UNKNOWN_TABLE) (version 25.3.6.10636.altinitytest (altinity build)) (from [::1]:52470) (comment: 01103_optimize_drop_race_zookeeper.sh) (query 1, line 1) (in query: INSERT INTO concurrent_optimize_table SELECT rand(1), rand(2), 1 / rand(3), toString(rand(4)), [rand(5), rand(6)], rand(7) % 2 ? NULL : generateUUIDv4(), (rand(8), rand(9)) FROM numbers(10000)), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000a06a8eb 4. /build/src/Databases/IDatabase.cpp:41: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x0000000013dd565f 5. /build/src/Interpreters/DatabaseCatalog.cpp:442: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x00000000144f0869 6. /build/src/Interpreters/DatabaseCatalog.cpp:976: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x00000000144f6c88 7. /build/src/Interpreters/InterpreterInsertQuery.cpp:169: DB::InterpreterInsertQuery::getTable(DB::ASTInsertQuery&) @ 0x000000001492bf04 8. /build/src/Interpreters/InterpreterInsertQuery.cpp:829: DB::InterpreterInsertQuery::execute() @ 0x0000000014933938 9. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88dc9 10. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 11. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 12. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 13. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 14. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 16. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 17. ? @ 0x00007fbc6213eac3 18. ? @ 0x00007fbc621d0850 2025.07.28 11:58:51.049151 [ 4446 ] {} TCPHandler: Code: 60. DB::Exception: Table test_15.concurrent_optimize_table does not exist. (UNKNOWN_TABLE), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000a06a8eb 4. /build/src/Databases/IDatabase.cpp:41: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x0000000013dd565f 5. /build/src/Interpreters/DatabaseCatalog.cpp:442: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x00000000144f0869 6. /build/src/Interpreters/DatabaseCatalog.cpp:976: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x00000000144f6c88 7. /build/src/Interpreters/InterpreterInsertQuery.cpp:169: DB::InterpreterInsertQuery::getTable(DB::ASTInsertQuery&) @ 0x000000001492bf04 8. /build/src/Interpreters/InterpreterInsertQuery.cpp:829: DB::InterpreterInsertQuery::execute() @ 0x0000000014933938 9. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88dc9 10. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 11. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 12. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 13. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 14. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 16. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 17. ? @ 0x00007fbc6213eac3 18. ? @ 0x00007fbc621d0850 2025.07.28 11:58:51.071285 [ 17270 ] {4c434698-2029-4c52-ae31-4d2f4f218f28} test_15.concurrent_optimize_table (113a053f-deb2-4203-9936-78900aecf5ef): The leftovers from table /clickhouse/tables/01103_optimize_drop_race_zookeeper_test_15/concurrent_optimize_table were removed by another replica 2025.07.28 11:58:51.087694 [ 4963 ] {b1675725-efe6-4af5-b256-4180cf2e5bbd} executeQuery: Code: 60. DB::Exception: Table test_15.concurrent_optimize_table does not exist. (UNKNOWN_TABLE) (version 25.3.6.10636.altinitytest (altinity build)) (from [::1]:52448) (comment: 01103_optimize_drop_race_zookeeper.sh) (query 1, line 1) (in query: INSERT INTO concurrent_optimize_table SELECT rand(1), rand(2), 1 / rand(3), toString(rand(4)), [rand(5), rand(6)], rand(7) % 2 ? NULL : generateUUIDv4(), (rand(8), rand(9)) FROM numbers(10000)), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000a06a8eb 4. /build/src/Databases/IDatabase.cpp:41: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x0000000013dd565f 5. /build/src/Interpreters/DatabaseCatalog.cpp:442: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x00000000144f0869 6. /build/src/Interpreters/DatabaseCatalog.cpp:976: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x00000000144f6c88 7. /build/src/Interpreters/InterpreterInsertQuery.cpp:169: DB::InterpreterInsertQuery::getTable(DB::ASTInsertQuery&) @ 0x000000001492bf04 8. /build/src/Interpreters/InterpreterInsertQuery.cpp:829: DB::InterpreterInsertQuery::execute() @ 0x0000000014933938 9. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88dc9 10. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 11. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 12. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 13. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 14. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 16. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 17. ? @ 0x00007fbc6213eac3 18. ? @ 0x00007fbc621d0850 2025.07.28 11:58:51.130039 [ 3287 ] {fe2eba42-a9af-400f-ae12-7272a814366f} executeQuery: Code: 60. DB::Exception: Table test_15.concurrent_optimize_table does not exist. (UNKNOWN_TABLE) (version 25.3.6.10636.altinitytest (altinity build)) (from [::1]:52494) (comment: 01103_optimize_drop_race_zookeeper.sh) (query 1, line 1) (in query: OPTIMIZE TABLE concurrent_optimize_table FINAL), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000a06a8eb 4. /build/src/Databases/IDatabase.cpp:41: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x0000000013dd565f 5. /build/src/Interpreters/DatabaseCatalog.cpp:442: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x00000000144f0869 6. /build/src/Interpreters/DatabaseCatalog.cpp:976: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x00000000144f6c88 7. /build/src/Interpreters/InterpreterOptimizeQuery.cpp:40: DB::InterpreterOptimizeQuery::execute() @ 0x0000000014cd71de 8. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88dc9 9. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 10. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 11. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 12. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 13. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 14. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 15. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 16. ? @ 0x00007fbc6213eac3 17. ? @ 0x00007fbc621d0850 2025.07.28 11:58:51.147796 [ 4963 ] {} TCPHandler: Code: 60. DB::Exception: Table test_15.concurrent_optimize_table does not exist. (UNKNOWN_TABLE), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000a06a8eb 4. /build/src/Databases/IDatabase.cpp:41: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x0000000013dd565f 5. /build/src/Interpreters/DatabaseCatalog.cpp:442: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x00000000144f0869 6. /build/src/Interpreters/DatabaseCatalog.cpp:976: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x00000000144f6c88 7. /build/src/Interpreters/InterpreterInsertQuery.cpp:169: DB::InterpreterInsertQuery::getTable(DB::ASTInsertQuery&) @ 0x000000001492bf04 8. /build/src/Interpreters/InterpreterInsertQuery.cpp:829: DB::InterpreterInsertQuery::execute() @ 0x0000000014933938 9. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88dc9 10. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 11. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 12. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 13. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 14. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 16. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 17. ? @ 0x00007fbc6213eac3 18. ? @ 0x00007fbc621d0850 2025.07.28 11:58:51.150567 [ 5327 ] {bbbe8da5-2f34-435a-b8cd-ee9bf24a5716} executeQuery: Code: 60. DB::Exception: Table test_15.concurrent_optimize_table does not exist. (UNKNOWN_TABLE) (version 25.3.6.10636.altinitytest (altinity build)) (from [::1]:52480) (comment: 01103_optimize_drop_race_zookeeper.sh) (query 1, line 1) (in query: INSERT INTO concurrent_optimize_table SELECT rand(1), rand(2), 1 / rand(3), toString(rand(4)), [rand(5), rand(6)], rand(7) % 2 ? NULL : generateUUIDv4(), (rand(8), rand(9)) FROM numbers(10000)), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000a06a8eb 4. /build/src/Databases/IDatabase.cpp:41: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x0000000013dd565f 5. /build/src/Interpreters/DatabaseCatalog.cpp:442: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x00000000144f0869 6. /build/src/Interpreters/DatabaseCatalog.cpp:976: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x00000000144f6c88 7. /build/src/Interpreters/InterpreterInsertQuery.cpp:169: DB::InterpreterInsertQuery::getTable(DB::ASTInsertQuery&) @ 0x000000001492bf04 8. /build/src/Interpreters/InterpreterInsertQuery.cpp:829: DB::InterpreterInsertQuery::execute() @ 0x0000000014933938 9. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88dc9 10. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 11. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 12. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 13. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 14. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 16. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 17. ? @ 0x00007fbc6213eac3 18. ? @ 0x00007fbc621d0850 2025.07.28 11:58:51.171797 [ 3287 ] {} TCPHandler: Code: 60. DB::Exception: Table test_15.concurrent_optimize_table does not exist. (UNKNOWN_TABLE), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000a06a8eb 4. /build/src/Databases/IDatabase.cpp:41: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x0000000013dd565f 5. /build/src/Interpreters/DatabaseCatalog.cpp:442: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x00000000144f0869 6. /build/src/Interpreters/DatabaseCatalog.cpp:976: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x00000000144f6c88 7. /build/src/Interpreters/InterpreterOptimizeQuery.cpp:40: DB::InterpreterOptimizeQuery::execute() @ 0x0000000014cd71de 8. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88dc9 9. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 10. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 11. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 12. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 13. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 14. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 15. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 16. ? @ 0x00007fbc6213eac3 17. ? @ 0x00007fbc621d0850 2025.07.28 11:58:51.201861 [ 5327 ] {} TCPHandler: Code: 60. DB::Exception: Table test_15.concurrent_optimize_table does not exist. (UNKNOWN_TABLE), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000a06a8eb 4. /build/src/Databases/IDatabase.cpp:41: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x0000000013dd565f 5. /build/src/Interpreters/DatabaseCatalog.cpp:442: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x00000000144f0869 6. /build/src/Interpreters/DatabaseCatalog.cpp:976: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x00000000144f6c88 7. /build/src/Interpreters/InterpreterInsertQuery.cpp:169: DB::InterpreterInsertQuery::getTable(DB::ASTInsertQuery&) @ 0x000000001492bf04 8. /build/src/Interpreters/InterpreterInsertQuery.cpp:829: DB::InterpreterInsertQuery::execute() @ 0x0000000014933938 9. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88dc9 10. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 11. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 12. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 13. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 14. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 16. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 17. ? @ 0x00007fbc6213eac3 18. ? @ 0x00007fbc621d0850 2025.07.28 11:58:51.245144 [ 17306 ] {0bfc1947-aec0-46f9-b3c5-c6197b60d7f2} executeQuery: Code: 60. DB::Exception: Table test_15.concurrent_optimize_table does not exist. (UNKNOWN_TABLE) (version 25.3.6.10636.altinitytest (altinity build)) (from [::1]:52504) (comment: 01103_optimize_drop_race_zookeeper.sh) (query 1, line 1) (in query: OPTIMIZE TABLE concurrent_optimize_table FINAL), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000a06a8eb 4. /build/src/Databases/IDatabase.cpp:41: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x0000000013dd565f 5. /build/src/Interpreters/DatabaseCatalog.cpp:442: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x00000000144f0869 6. /build/src/Interpreters/DatabaseCatalog.cpp:976: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x00000000144f6c88 7. /build/src/Interpreters/InterpreterOptimizeQuery.cpp:40: DB::InterpreterOptimizeQuery::execute() @ 0x0000000014cd71de 8. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88dc9 9. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 10. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 11. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 12. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 13. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 14. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 15. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 16. ? @ 0x00007fbc6213eac3 17. ? @ 0x00007fbc621d0850 2025.07.28 11:58:51.256672 [ 17306 ] {} TCPHandler: Code: 60. DB::Exception: Table test_15.concurrent_optimize_table does not exist. (UNKNOWN_TABLE), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000a06a8eb 4. /build/src/Databases/IDatabase.cpp:41: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x0000000013dd565f 5. /build/src/Interpreters/DatabaseCatalog.cpp:442: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x00000000144f0869 6. /build/src/Interpreters/DatabaseCatalog.cpp:976: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x00000000144f6c88 7. /build/src/Interpreters/InterpreterOptimizeQuery.cpp:40: DB::InterpreterOptimizeQuery::execute() @ 0x0000000014cd71de 8. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88dc9 9. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 10. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 11. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 12. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 13. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 14. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 15. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 16. ? @ 0x00007fbc6213eac3 17. ? @ 0x00007fbc621d0850 2025.07.28 11:58:51.354286 [ 17203 ] {920e39b6-4533-4405-bdc0-50494b0c9cf5} executeQuery: Code: 60. DB::Exception: Table test_15.concurrent_optimize_table does not exist. (UNKNOWN_TABLE) (version 25.3.6.10636.altinitytest (altinity build)) (from [::1]:39864) (comment: 01103_optimize_drop_race_zookeeper.sh) (query 1, line 1) (in query: INSERT INTO concurrent_optimize_table SELECT rand(1), rand(2), 1 / rand(3), toString(rand(4)), [rand(5), rand(6)], rand(7) % 2 ? NULL : generateUUIDv4(), (rand(8), rand(9)) FROM numbers(10000)), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000a06a8eb 4. /build/src/Databases/IDatabase.cpp:41: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x0000000013dd565f 5. /build/src/Interpreters/DatabaseCatalog.cpp:442: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x00000000144f0869 6. /build/src/Interpreters/DatabaseCatalog.cpp:976: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x00000000144f6c88 7. /build/src/Interpreters/InterpreterInsertQuery.cpp:169: DB::InterpreterInsertQuery::getTable(DB::ASTInsertQuery&) @ 0x000000001492bf04 8. /build/src/Interpreters/InterpreterInsertQuery.cpp:829: DB::InterpreterInsertQuery::execute() @ 0x0000000014933938 9. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88dc9 10. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 11. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 12. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 13. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 14. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 16. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 17. ? @ 0x00007fbc6213eac3 18. ? @ 0x00007fbc621d0850 2025.07.28 11:58:51.368149 [ 17203 ] {} TCPHandler: Code: 60. DB::Exception: Table test_15.concurrent_optimize_table does not exist. (UNKNOWN_TABLE), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000a06a8eb 4. /build/src/Databases/IDatabase.cpp:41: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x0000000013dd565f 5. /build/src/Interpreters/DatabaseCatalog.cpp:442: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x00000000144f0869 6. /build/src/Interpreters/DatabaseCatalog.cpp:976: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x00000000144f6c88 7. /build/src/Interpreters/InterpreterInsertQuery.cpp:169: DB::InterpreterInsertQuery::getTable(DB::ASTInsertQuery&) @ 0x000000001492bf04 8. /build/src/Interpreters/InterpreterInsertQuery.cpp:829: DB::InterpreterInsertQuery::execute() @ 0x0000000014933938 9. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88dc9 10. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 11. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 12. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 13. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 14. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 16. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 17. ? @ 0x00007fbc6213eac3 18. ? @ 0x00007fbc621d0850 2025.07.28 11:58:51.372857 [ 3977 ] {} test_13.rmt2 (7f9b740d-015c-470e-8cc6-8ba33be0dc63): auto DB::StorageReplicatedMergeTree::processQueueEntry(ReplicatedMergeTreeQueue::SelectedEntryPtr)::(anonymous class)::operator()(LogEntryPtr &) const: Code: 86. DB::HTTPException: Received error from remote server http://146b4357c08d:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Ftest%2F01165%2Ftest_13%2Frmt%2Freplicas%2F1&part=20250728_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.6.10636.altinitytest (altinity build)) '. (RECEIVED_ERROR_FROM_REMOTE_IO_SERVER), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.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 const&, int&&, String const&, unsigned long&&, String const&) @ 0x000000000feda8d9 4. /build/src/IO/HTTPCommon.cpp:104: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x000000000feda6e2 5. /build/src/IO/HTTPCommon.cpp:93: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x000000000feda537 6. /build/src/IO/ReadWriteBufferFromHTTP.cpp:277: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x000000001184a4c4 7. /build/src/IO/ReadWriteBufferFromHTTP.cpp:285: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x000000001184a615 8. /build/src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x000000001184ae59 9. /build/src/IO/ReadWriteBufferFromHTTP.cpp:472: void std::__function::__policy_invoker::__call_impl[abi:se190107]>(std::__function::__policy_storage const*) @ 0x000000001184cedd 10. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001184858b 11. /build/src/IO/ReadWriteBufferFromHTTP.cpp:465: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x000000001184bf0b 12. /build/src/IO/ReadBuffer.h:60: DB::ReadBuffer::next() @ 0x000000000a148c7b 13. /build/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) @ 0x0000000011849fb2 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]>&)>&, 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&) @ 0x0000000011841980 15. /build/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) @ 0x000000001621208e 16. /build/src/Storages/StorageReplicatedMergeTree.cpp:5228: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl[abi:se190107] const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000015f9a5fe 17. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000015ed8bfd 18. /build/src/Storages/StorageReplicatedMergeTree.cpp:2514: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x0000000015ec9aab 19. /build/src/Storages/StorageReplicatedMergeTree.cpp:2349: DB::StorageReplicatedMergeTree::executeLogEntry(DB::ReplicatedMergeTreeLogEntry&) @ 0x0000000015eba91b 20. /build/src/Storages/StorageReplicatedMergeTree.cpp:3876: bool std::__function::__policy_invoker&)>::__call_impl[abi:se190107])::$_1, bool (std::shared_ptr&)>>(std::__function::__policy_storage const*, std::shared_ptr&) @ 0x0000000015f9837e 21. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000165d6fc3 22. /build/src/Storages/StorageReplicatedMergeTree.cpp:3872: DB::StorageReplicatedMergeTree::processQueueEntry(std::shared_ptr) @ 0x0000000015efc18a 23. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001624c1b2 24. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000162f9c70 25. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x00000000162fa55a 26. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc6653 27. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000000fccc4c3 28. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc3d92 29. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fcca080 30. ? @ 0x00007fbc6213eac3 31. ? @ 0x00007fbc621d0850 (version 25.3.6.10636.altinitytest (altinity build)) 2025.07.28 11:58:51.390858 [ 4446 ] {bb292b27-e696-4a41-8f09-6d707b8497c6} executeQuery: Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01103_optimize_drop_race_zookeeper_test_15/concurrent_optimize_table/replicas/1). (TABLE_IS_READ_ONLY) (version 25.3.6.10636.altinitytest (altinity build)) (from [::1]:39888) (comment: 01103_optimize_drop_race_zookeeper.sh) (query 1, line 1) (in query: OPTIMIZE TABLE concurrent_optimize_table FINAL), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000a9b78ab 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:5935: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000015e86144 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:6112: DB::StorageReplicatedMergeTree::optimize(std::shared_ptr const&, std::shared_ptr const&, std::shared_ptr const&, bool, bool, std::vector> const&, bool, std::shared_ptr) @ 0x0000000015f21f2c 6. /build/src/Interpreters/InterpreterOptimizeQuery.cpp:84: DB::InterpreterOptimizeQuery::execute() @ 0x0000000014cd782e 7. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88dc9 8. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 9. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 10. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 11. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 12. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 13. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 14. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 15. ? @ 0x00007fbc6213eac3 16. ? @ 0x00007fbc621d0850 2025.07.28 11:58:51.400395 [ 4446 ] {} TCPHandler: Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01103_optimize_drop_race_zookeeper_test_15/concurrent_optimize_table/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000a9b78ab 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:5935: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x0000000015e86144 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:6112: DB::StorageReplicatedMergeTree::optimize(std::shared_ptr const&, std::shared_ptr const&, std::shared_ptr const&, bool, bool, std::vector> const&, bool, std::shared_ptr) @ 0x0000000015f21f2c 6. /build/src/Interpreters/InterpreterOptimizeQuery.cpp:84: DB::InterpreterOptimizeQuery::execute() @ 0x0000000014cd782e 7. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88dc9 8. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 9. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 10. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 11. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 12. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 13. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 14. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 15. ? @ 0x00007fbc6213eac3 16. ? @ 0x00007fbc621d0850 2025.07.28 11:58:51.489428 [ 3283 ] {463e3a9b-5440-4ed7-9e7d-edcaa007bd48} executeQuery: Code: 57. DB::Exception: Table test_15.concurrent_optimize_table already exists. (TABLE_ALREADY_EXISTS) (version 25.3.6.10636.altinitytest (altinity build)) (from [::1]:52052) (comment: 01103_optimize_drop_race_zookeeper.sh) (query 2, line 2) (in query: CREATE TABLE concurrent_optimize_table (`a` UInt8, `b` Int16, `c` Float32, `d` String, `e` Array(UInt8), `f` Nullable(UUID), `g` Tuple(UInt8, UInt16)) ENGINE = ReplicatedMergeTree('/clickhouse/tables/01103_optimize_drop_race_zookeeper_test_15/concurrent_optimize_table', '1') PARTITION BY b % 10 ORDER BY a SETTINGS old_parts_lifetime = 1, cleanup_delay_period = 0, cleanup_delay_period_random_add = 0, cleanup_thread_preferred_points_per_iteration = 0, index_granularity = 31489, 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 = 20868213, compact_parts_max_bytes_to_buffer = 108362629, compact_parts_max_granules_to_buffer = 1, compact_parts_merge_max_bytes_to_prefetch_part = 18898448, merge_max_block_size = 13220, prefer_fetch_merged_part_size_threshold = 1, vertical_merge_algorithm_min_rows_to_activate = 1000000, vertical_merge_algorithm_min_columns_to_activate = 76, min_merge_bytes_to_use_direct_io = 10737418240, index_granularity_bytes = 7046892, use_const_adaptive_granularity = false, 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 = true, cache_populated_by_fetch = false, marks_compress_block_size = 84392, primary_key_compress_block_size = 23861, 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. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000a06a8eb 4. /build/src/Interpreters/InterpreterCreateQuery.cpp:1824: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x0000000014901d53 5. /build/src/Interpreters/InterpreterCreateQuery.cpp:1743: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000148f9aa9 6. /build/src/Interpreters/InterpreterCreateQuery.cpp:2352: DB::InterpreterCreateQuery::execute() @ 0x0000000014905a41 7. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88dc9 8. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 9. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 10. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 11. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 12. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 13. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 14. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 15. ? @ 0x00007fbc6213eac3 16. ? @ 0x00007fbc621d0850 2025.07.28 11:58:51.507478 [ 3283 ] {} TCPHandler: Code: 57. DB::Exception: Table test_15.concurrent_optimize_table already exists. (TABLE_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000a06a8eb 4. /build/src/Interpreters/InterpreterCreateQuery.cpp:1824: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x0000000014901d53 5. /build/src/Interpreters/InterpreterCreateQuery.cpp:1743: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000148f9aa9 6. /build/src/Interpreters/InterpreterCreateQuery.cpp:2352: DB::InterpreterCreateQuery::execute() @ 0x0000000014905a41 7. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88dc9 8. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 9. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 10. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 11. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 12. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 13. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 14. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 15. ? @ 0x00007fbc6213eac3 16. ? @ 0x00007fbc621d0850 2025.07.28 11:58:51.540548 [ 3969 ] {} test_13.rmt2 (7f9b740d-015c-470e-8cc6-8ba33be0dc63): auto DB::StorageReplicatedMergeTree::processQueueEntry(ReplicatedMergeTreeQueue::SelectedEntryPtr)::(anonymous class)::operator()(LogEntryPtr &) const: Code: 86. DB::HTTPException: Received error from remote server http://146b4357c08d:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Ftest%2F01165%2Ftest_13%2Frmt%2Freplicas%2F1&part=20250728_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.6.10636.altinitytest (altinity build)) '. (RECEIVED_ERROR_FROM_REMOTE_IO_SERVER), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.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 const&, int&&, String const&, unsigned long&&, String const&) @ 0x000000000feda8d9 4. /build/src/IO/HTTPCommon.cpp:104: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x000000000feda6e2 5. /build/src/IO/HTTPCommon.cpp:93: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x000000000feda537 6. /build/src/IO/ReadWriteBufferFromHTTP.cpp:277: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x000000001184a4c4 7. /build/src/IO/ReadWriteBufferFromHTTP.cpp:285: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x000000001184a615 8. /build/src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x000000001184ae59 9. /build/src/IO/ReadWriteBufferFromHTTP.cpp:472: void std::__function::__policy_invoker::__call_impl[abi:se190107]>(std::__function::__policy_storage const*) @ 0x000000001184cedd 10. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001184858b 11. /build/src/IO/ReadWriteBufferFromHTTP.cpp:465: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x000000001184bf0b 12. /build/src/IO/ReadBuffer.h:60: DB::ReadBuffer::next() @ 0x000000000a148c7b 13. /build/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) @ 0x0000000011849fb2 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]>&)>&, 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&) @ 0x0000000011841980 15. /build/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) @ 0x000000001621208e 16. /build/src/Storages/StorageReplicatedMergeTree.cpp:5228: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl[abi:se190107] const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000015f9a5fe 17. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000015ed8bfd 18. /build/src/Storages/StorageReplicatedMergeTree.cpp:2514: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x0000000015ec9aab 19. /build/src/Storages/StorageReplicatedMergeTree.cpp:2349: DB::StorageReplicatedMergeTree::executeLogEntry(DB::ReplicatedMergeTreeLogEntry&) @ 0x0000000015eba91b 20. /build/src/Storages/StorageReplicatedMergeTree.cpp:3876: bool std::__function::__policy_invoker&)>::__call_impl[abi:se190107])::$_1, bool (std::shared_ptr&)>>(std::__function::__policy_storage const*, std::shared_ptr&) @ 0x0000000015f9837e 21. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000165d6fc3 22. /build/src/Storages/StorageReplicatedMergeTree.cpp:3872: DB::StorageReplicatedMergeTree::processQueueEntry(std::shared_ptr) @ 0x0000000015efc18a 23. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001624c1b2 24. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000162f9c70 25. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x00000000162fa55a 26. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc6653 27. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000000fccc4c3 28. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc3d92 29. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fcca080 30. ? @ 0x00007fbc6213eac3 31. ? @ 0x00007fbc621d0850 (version 25.3.6.10636.altinitytest (altinity build)) 2025.07.28 11:58:51.788000 [ 17208 ] {88ee814e-2e8b-4348-92eb-322a135f36f5} executeQuery: Code: 60. DB::Exception: Table test_15.concurrent_optimize_table does not exist. (UNKNOWN_TABLE) (version 25.3.6.10636.altinitytest (altinity build)) (from [::1]:39974) (comment: 01103_optimize_drop_race_zookeeper.sh) (query 1, line 1) (in query: OPTIMIZE TABLE concurrent_optimize_table FINAL), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000a06a8eb 4. /build/src/Databases/IDatabase.cpp:41: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x0000000013dd565f 5. /build/src/Interpreters/DatabaseCatalog.cpp:442: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x00000000144f0869 6. /build/src/Interpreters/DatabaseCatalog.cpp:976: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x00000000144f6c88 7. /build/src/Interpreters/InterpreterOptimizeQuery.cpp:40: DB::InterpreterOptimizeQuery::execute() @ 0x0000000014cd71de 8. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88dc9 9. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 10. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 11. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 12. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 13. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 14. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 15. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 16. ? @ 0x00007fbc6213eac3 17. ? @ 0x00007fbc621d0850 2025.07.28 11:58:51.800306 [ 17557 ] {e950da4d-afa4-4430-80a6-fb25bba59504} executeQuery: Code: 60. DB::Exception: Table test_15.concurrent_optimize_table does not exist. (UNKNOWN_TABLE) (version 25.3.6.10636.altinitytest (altinity build)) (from [::1]:39978) (comment: 01103_optimize_drop_race_zookeeper.sh) (query 1, line 1) (in query: OPTIMIZE TABLE concurrent_optimize_table FINAL), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000a06a8eb 4. /build/src/Databases/IDatabase.cpp:41: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x0000000013dd565f 5. /build/src/Interpreters/DatabaseCatalog.cpp:442: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x00000000144f0869 6. /build/src/Interpreters/DatabaseCatalog.cpp:976: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x00000000144f6c88 7. /build/src/Interpreters/InterpreterOptimizeQuery.cpp:40: DB::InterpreterOptimizeQuery::execute() @ 0x0000000014cd71de 8. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88dc9 9. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 10. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 11. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 12. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 13. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 14. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 15. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 16. ? @ 0x00007fbc6213eac3 17. ? @ 0x00007fbc621d0850 2025.07.28 11:58:51.819685 [ 17208 ] {} TCPHandler: Code: 60. DB::Exception: Table test_15.concurrent_optimize_table does not exist. (UNKNOWN_TABLE), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000a06a8eb 4. /build/src/Databases/IDatabase.cpp:41: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x0000000013dd565f 5. /build/src/Interpreters/DatabaseCatalog.cpp:442: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x00000000144f0869 6. /build/src/Interpreters/DatabaseCatalog.cpp:976: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x00000000144f6c88 7. /build/src/Interpreters/InterpreterOptimizeQuery.cpp:40: DB::InterpreterOptimizeQuery::execute() @ 0x0000000014cd71de 8. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88dc9 9. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 10. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 11. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 12. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 13. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 14. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 15. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 16. ? @ 0x00007fbc6213eac3 17. ? @ 0x00007fbc621d0850 2025.07.28 11:58:51.851569 [ 17557 ] {} TCPHandler: Code: 60. DB::Exception: Table test_15.concurrent_optimize_table does not exist. (UNKNOWN_TABLE), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000a06a8eb 4. /build/src/Databases/IDatabase.cpp:41: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x0000000013dd565f 5. /build/src/Interpreters/DatabaseCatalog.cpp:442: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x00000000144f0869 6. /build/src/Interpreters/DatabaseCatalog.cpp:976: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x00000000144f6c88 7. /build/src/Interpreters/InterpreterOptimizeQuery.cpp:40: DB::InterpreterOptimizeQuery::execute() @ 0x0000000014cd71de 8. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88dc9 9. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 10. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 11. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 12. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 13. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 14. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 15. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 16. ? @ 0x00007fbc6213eac3 17. ? @ 0x00007fbc621d0850 2025.07.28 11:58:51.959204 [ 3285 ] {4e1816ef-ce83-48fd-89ed-64b8e1dd397a} executeQuery: Code: 60. DB::Exception: Table test_15.concurrent_optimize_table does not exist. (UNKNOWN_TABLE) (version 25.3.6.10636.altinitytest (altinity build)) (from [::1]:39982) (comment: 01103_optimize_drop_race_zookeeper.sh) (query 1, line 1) (in query: OPTIMIZE TABLE concurrent_optimize_table FINAL), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000a06a8eb 4. /build/src/Databases/IDatabase.cpp:41: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x0000000013dd565f 5. /build/src/Interpreters/DatabaseCatalog.cpp:442: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x00000000144f0869 6. /build/src/Interpreters/DatabaseCatalog.cpp:976: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x00000000144f6c88 7. /build/src/Interpreters/InterpreterOptimizeQuery.cpp:40: DB::InterpreterOptimizeQuery::execute() @ 0x0000000014cd71de 8. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88dc9 9. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 10. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 11. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 12. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 13. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 14. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 15. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 16. ? @ 0x00007fbc6213eac3 17. ? @ 0x00007fbc621d0850 2025.07.28 11:58:51.993174 [ 3285 ] {} TCPHandler: Code: 60. DB::Exception: Table test_15.concurrent_optimize_table does not exist. (UNKNOWN_TABLE), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000a06a8eb 4. /build/src/Databases/IDatabase.cpp:41: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x0000000013dd565f 5. /build/src/Interpreters/DatabaseCatalog.cpp:442: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x00000000144f0869 6. /build/src/Interpreters/DatabaseCatalog.cpp:976: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x00000000144f6c88 7. /build/src/Interpreters/InterpreterOptimizeQuery.cpp:40: DB::InterpreterOptimizeQuery::execute() @ 0x0000000014cd71de 8. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88dc9 9. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 10. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 11. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 12. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 13. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 14. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 15. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 16. ? @ 0x00007fbc6213eac3 17. ? @ 0x00007fbc621d0850 2025.07.28 11:58:52.079853 [ 3287 ] {e8ba40b9-df06-4740-b3e5-e7fff624216d} executeQuery: Code: 253. DB::Exception: Replica /clickhouse/tables/01103_optimize_drop_race_zookeeper_test_15/concurrent_optimize_table/replicas/1 already exists. (REPLICA_ALREADY_EXISTS) (version 25.3.6.10636.altinitytest (altinity build)) (from [::1]:39902) (comment: 01103_optimize_drop_race_zookeeper.sh) (query 2, line 2) (in query: CREATE TABLE concurrent_optimize_table (`a` UInt8, `b` Int16, `c` Float32, `d` String, `e` Array(UInt8), `f` Nullable(UUID), `g` Tuple(UInt8, UInt16)) ENGINE = ReplicatedMergeTree('/clickhouse/tables/01103_optimize_drop_race_zookeeper_test_15/concurrent_optimize_table', '1') PARTITION BY b % 10 ORDER BY a SETTINGS old_parts_lifetime = 1, cleanup_delay_period = 0, cleanup_delay_period_random_add = 0, cleanup_thread_preferred_points_per_iteration = 0, index_granularity = 31489, 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 = 20868213, compact_parts_max_bytes_to_buffer = 108362629, compact_parts_max_granules_to_buffer = 1, compact_parts_merge_max_bytes_to_prefetch_part = 18898448, merge_max_block_size = 13220, prefer_fetch_merged_part_size_threshold = 1, vertical_merge_algorithm_min_rows_to_activate = 1000000, vertical_merge_algorithm_min_columns_to_activate = 76, min_merge_bytes_to_use_direct_io = 10737418240, index_granularity_bytes = 7046892, use_const_adaptive_granularity = false, 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 = true, cache_populated_by_fetch = false, marks_compress_block_size = 84392, primary_key_compress_block_size = 23861, 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. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000a9b78ab 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:1237: DB::StorageReplicatedMergeTree::createReplicaAttempt(std::shared_ptr const&, std::shared_ptr) const @ 0x0000000015ea1634 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:1087: DB::StorageReplicatedMergeTree::createReplica(std::shared_ptr const&, DB::ZooKeeperRetriesInfo const&) const @ 0x0000000015e8c7b5 6. /build/src/Storages/StorageReplicatedMergeTree.cpp:624: DB::StorageReplicatedMergeTree::StorageReplicatedMergeTree(DB::TableZnodeInfo const&, DB::LoadingStrictnessLevel, DB::StorageID const&, String const&, DB::StorageInMemoryMetadata const&, std::shared_ptr, String const&, DB::MergeTreeData::MergingParams const&, std::unique_ptr>, bool, DB::ZooKeeperRetriesInfo const&) @ 0x0000000015e8979f 7. /build/contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: std::shared_ptr std::allocate_shared[abi:se190107], DB::TableZnodeInfo&, DB::LoadingStrictnessLevel const&, DB::StorageID const&, String const&, DB::StorageInMemoryMetadata&, std::shared_ptr&, String&, DB::MergeTreeData::MergingParams&, std::unique_ptr>, bool&, DB::ZooKeeperRetriesInfo&, 0>(std::allocator const&, DB::TableZnodeInfo&, DB::LoadingStrictnessLevel const&, DB::StorageID const&, String const&, DB::StorageInMemoryMetadata&, std::shared_ptr&, String&, DB::MergeTreeData::MergingParams&, std::unique_ptr>&&, bool&, DB::ZooKeeperRetriesInfo&) @ 0x000000001663250b 8. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:851: DB::create(DB::StorageFactory::Arguments const&) @ 0x000000001662ef92 9. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000015d81ea2 10. /build/src/Interpreters/InterpreterCreateQuery.cpp:1945: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x00000000149009bb 11. /build/src/Interpreters/InterpreterCreateQuery.cpp:1743: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000148f9aa9 12. /build/src/Interpreters/InterpreterCreateQuery.cpp:2352: DB::InterpreterCreateQuery::execute() @ 0x0000000014905a41 13. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88dc9 14. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 15. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 16. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 17. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 18. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 19. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 20. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 21. ? @ 0x00007fbc6213eac3 22. ? @ 0x00007fbc621d0850 2025.07.28 11:58:52.132743 [ 3287 ] {} TCPHandler: Code: 253. DB::Exception: Replica /clickhouse/tables/01103_optimize_drop_race_zookeeper_test_15/concurrent_optimize_table/replicas/1 already exists. (REPLICA_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000a9b78ab 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:1237: DB::StorageReplicatedMergeTree::createReplicaAttempt(std::shared_ptr const&, std::shared_ptr) const @ 0x0000000015ea1634 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:1087: DB::StorageReplicatedMergeTree::createReplica(std::shared_ptr const&, DB::ZooKeeperRetriesInfo const&) const @ 0x0000000015e8c7b5 6. /build/src/Storages/StorageReplicatedMergeTree.cpp:624: DB::StorageReplicatedMergeTree::StorageReplicatedMergeTree(DB::TableZnodeInfo const&, DB::LoadingStrictnessLevel, DB::StorageID const&, String const&, DB::StorageInMemoryMetadata const&, std::shared_ptr, String const&, DB::MergeTreeData::MergingParams const&, std::unique_ptr>, bool, DB::ZooKeeperRetriesInfo const&) @ 0x0000000015e8979f 7. /build/contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: std::shared_ptr std::allocate_shared[abi:se190107], DB::TableZnodeInfo&, DB::LoadingStrictnessLevel const&, DB::StorageID const&, String const&, DB::StorageInMemoryMetadata&, std::shared_ptr&, String&, DB::MergeTreeData::MergingParams&, std::unique_ptr>, bool&, DB::ZooKeeperRetriesInfo&, 0>(std::allocator const&, DB::TableZnodeInfo&, DB::LoadingStrictnessLevel const&, DB::StorageID const&, String const&, DB::StorageInMemoryMetadata&, std::shared_ptr&, String&, DB::MergeTreeData::MergingParams&, std::unique_ptr>&&, bool&, DB::ZooKeeperRetriesInfo&) @ 0x000000001663250b 8. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:851: DB::create(DB::StorageFactory::Arguments const&) @ 0x000000001662ef92 9. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000015d81ea2 10. /build/src/Interpreters/InterpreterCreateQuery.cpp:1945: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x00000000149009bb 11. /build/src/Interpreters/InterpreterCreateQuery.cpp:1743: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000148f9aa9 12. /build/src/Interpreters/InterpreterCreateQuery.cpp:2352: DB::InterpreterCreateQuery::execute() @ 0x0000000014905a41 13. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88dc9 14. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 15. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 16. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 17. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 18. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 19. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 20. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 21. ? @ 0x00007fbc6213eac3 22. ? @ 0x00007fbc621d0850 2025.07.28 11:58:52.178398 [ 17208 ] {6d3c58c6-e54c-49b1-a261-d827641ba897} executeQuery: Code: 60. DB::Exception: Table test_15.concurrent_optimize_table does not exist. (UNKNOWN_TABLE) (version 25.3.6.10636.altinitytest (altinity build)) (from [::1]:40004) (comment: 01103_optimize_drop_race_zookeeper.sh) (query 1, line 1) (in query: OPTIMIZE TABLE concurrent_optimize_table FINAL), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000a06a8eb 4. /build/src/Databases/IDatabase.cpp:41: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x0000000013dd565f 5. /build/src/Interpreters/DatabaseCatalog.cpp:442: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x00000000144f0869 6. /build/src/Interpreters/DatabaseCatalog.cpp:976: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x00000000144f6c88 7. /build/src/Interpreters/InterpreterOptimizeQuery.cpp:40: DB::InterpreterOptimizeQuery::execute() @ 0x0000000014cd71de 8. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88dc9 9. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 10. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 11. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 12. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 13. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 14. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 15. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 16. ? @ 0x00007fbc6213eac3 17. ? @ 0x00007fbc621d0850 2025.07.28 11:58:52.209502 [ 17208 ] {} TCPHandler: Code: 60. DB::Exception: Table test_15.concurrent_optimize_table does not exist. (UNKNOWN_TABLE), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000a06a8eb 4. /build/src/Databases/IDatabase.cpp:41: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x0000000013dd565f 5. /build/src/Interpreters/DatabaseCatalog.cpp:442: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x00000000144f0869 6. /build/src/Interpreters/DatabaseCatalog.cpp:976: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x00000000144f6c88 7. /build/src/Interpreters/InterpreterOptimizeQuery.cpp:40: DB::InterpreterOptimizeQuery::execute() @ 0x0000000014cd71de 8. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88dc9 9. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 10. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 11. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 12. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 13. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 14. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 15. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 16. ? @ 0x00007fbc6213eac3 17. ? @ 0x00007fbc621d0850 2025.07.28 11:58:52.271042 [ 3287 ] {e8c7a4ea-5da1-4741-a435-c87bb722608c} executeQuery: Code: 60. DB::Exception: Table test_15.concurrent_optimize_table does not exist. (UNKNOWN_TABLE) (version 25.3.6.10636.altinitytest (altinity build)) (from [::1]:40008) (comment: 01103_optimize_drop_race_zookeeper.sh) (query 1, line 1) (in query: OPTIMIZE TABLE concurrent_optimize_table FINAL), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000a06a8eb 4. /build/src/Databases/IDatabase.cpp:41: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x0000000013dd565f 5. /build/src/Interpreters/DatabaseCatalog.cpp:442: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x00000000144f0869 6. /build/src/Interpreters/DatabaseCatalog.cpp:976: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x00000000144f6c88 7. /build/src/Interpreters/InterpreterOptimizeQuery.cpp:40: DB::InterpreterOptimizeQuery::execute() @ 0x0000000014cd71de 8. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88dc9 9. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 10. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 11. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 12. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 13. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 14. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 15. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 16. ? @ 0x00007fbc6213eac3 17. ? @ 0x00007fbc621d0850 2025.07.28 11:58:52.300942 [ 3287 ] {} TCPHandler: Code: 60. DB::Exception: Table test_15.concurrent_optimize_table does not exist. (UNKNOWN_TABLE), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000a06a8eb 4. /build/src/Databases/IDatabase.cpp:41: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x0000000013dd565f 5. /build/src/Interpreters/DatabaseCatalog.cpp:442: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x00000000144f0869 6. /build/src/Interpreters/DatabaseCatalog.cpp:976: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x00000000144f6c88 7. /build/src/Interpreters/InterpreterOptimizeQuery.cpp:40: DB::InterpreterOptimizeQuery::execute() @ 0x0000000014cd71de 8. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88dc9 9. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 10. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 11. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 12. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 13. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 14. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 15. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 16. ? @ 0x00007fbc6213eac3 17. ? @ 0x00007fbc621d0850 2025.07.28 11:58:52.318890 [ 4446 ] {7eebff9d-cae1-413c-a36e-720acefe06d9} executeQuery: Code: 242. DB::Exception: Table is in readonly mode due to shutdown: replica_path=/clickhouse/tables/01103_optimize_drop_race_zookeeper_test_15/concurrent_optimize_table/replicas/1. (TABLE_IS_READ_ONLY) (version 25.3.6.10636.altinitytest (altinity build)) (from [::1]:39962) (comment: 01103_optimize_drop_race_zookeeper.sh) (query 1, line 1) (in query: INSERT INTO concurrent_optimize_table SELECT rand(1), rand(2), 1 / rand(3), toString(rand(4)), [rand(5), rand(6)], rand(7) % 2 ? NULL : generateUUIDv4(), (rand(8), rand(9)) FROM numbers(10000)), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000a9b78ab 4. /build/src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:866: DB::ReplicatedMergeTreeSinkImpl::commitPart(std::shared_ptr const&, std::shared_ptr&, String const&, unsigned long)::'lambda1'()::operator()() const @ 0x000000001660eed7 5. /build/src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:1124: DB::ReplicatedMergeTreeSinkImpl::commitPart(std::shared_ptr const&, std::shared_ptr&, String const&, unsigned long)::'lambda2'()::operator()() const @ 0x000000001660d1f2 6. /build/src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:1157: void DB::ZooKeeperRetriesControl::retryLoop::commitPart(std::shared_ptr const&, std::shared_ptr&, String const&, unsigned long)::'lambda3'()&, void DB::ZooKeeperRetriesControl::retryLoop::commitPart(std::shared_ptr const&, std::shared_ptr&, String const&, unsigned long)::'lambda3'()>(DB::ReplicatedMergeTreeSinkImpl::commitPart(std::shared_ptr const&, std::shared_ptr&, String const&, unsigned long)::'lambda3'()&&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::commitPart(std::shared_ptr const&, std::shared_ptr&, String const&, unsigned long)::'lambda3'()&&, void DB::ZooKeeperRetriesControl::retryLoop::commitPart(std::shared_ptr const&, std::shared_ptr&, String const&, unsigned long)::'lambda3'()>(DB::ReplicatedMergeTreeSinkImpl::commitPart(std::shared_ptr const&, std::shared_ptr&, String const&, unsigned long)::'lambda3'()&&)::'lambda'()&&) @ 0x000000001660d07f 7. /build/src/Common/ZooKeeper/ZooKeeperRetries.h:52: DB::ReplicatedMergeTreeSinkImpl::commitPart(std::shared_ptr const&, std::shared_ptr&, String const&, unsigned long) @ 0x00000000165fd951 8. /build/src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:492: DB::ReplicatedMergeTreeSinkImpl::finishDelayedChunk(std::shared_ptr const&) @ 0x00000000165f277d 9. /build/src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:437: DB::ReplicatedMergeTreeSinkImpl::consume(DB::Chunk&) @ 0x00000000165fbd00 10. /build/src/Processors/Sinks/SinkToStorage.cpp:10: DB::SinkToStorage::onConsume(DB::Chunk) @ 0x0000000016cee093 11. /build/src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: void std::__function::__policy_invoker::__call_impl[abi:se190107]>(std::__function::__policy_storage const*) @ 0x0000000016c0ad89 12. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000016c0abf5 13. /build/src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: DB::ExceptionKeepingTransform::work() @ 0x0000000016c0a6fe 14. /build/src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x00000000169bd00f 15. /build/src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x00000000169b2105 16. /build/src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeSingleThread(unsigned long) @ 0x00000000169b23be 17. /build/src/Processors/Executors/PipelineExecutor.cpp:416: void std::__function::__policy_invoker::__call_impl[abi:se190107]>(std::__function::__policy_storage const*) @ 0x00000000169b2e3f 18. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc6653 19. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000000fccc4c3 20. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc3d92 21. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fcca080 22. ? @ 0x00007fbc6213eac3 23. ? @ 0x00007fbc621d0850 2025.07.28 11:58:52.345297 [ 4581 ] {ad365aab-e9a4-4176-804e-76d948ffc6c9} executeQuery: Code: 242. DB::Exception: Table is in readonly mode due to shutdown: replica_path=/clickhouse/tables/01103_optimize_drop_race_zookeeper_test_15/concurrent_optimize_table/replicas/1. (TABLE_IS_READ_ONLY) (version 25.3.6.10636.altinitytest (altinity build)) (from [::1]:39878) (comment: 01103_optimize_drop_race_zookeeper.sh) (query 1, line 1) (in query: INSERT INTO concurrent_optimize_table SELECT rand(1), rand(2), 1 / rand(3), toString(rand(4)), [rand(5), rand(6)], rand(7) % 2 ? NULL : generateUUIDv4(), (rand(8), rand(9)) FROM numbers(10000)), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000a9b78ab 4. /build/src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:866: DB::ReplicatedMergeTreeSinkImpl::commitPart(std::shared_ptr const&, std::shared_ptr&, String const&, unsigned long)::'lambda1'()::operator()() const @ 0x000000001660eed7 5. /build/src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:1124: DB::ReplicatedMergeTreeSinkImpl::commitPart(std::shared_ptr const&, std::shared_ptr&, String const&, unsigned long)::'lambda2'()::operator()() const @ 0x000000001660d1f2 6. /build/src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:1157: void DB::ZooKeeperRetriesControl::retryLoop::commitPart(std::shared_ptr const&, std::shared_ptr&, String const&, unsigned long)::'lambda3'()&, void DB::ZooKeeperRetriesControl::retryLoop::commitPart(std::shared_ptr const&, std::shared_ptr&, String const&, unsigned long)::'lambda3'()>(DB::ReplicatedMergeTreeSinkImpl::commitPart(std::shared_ptr const&, std::shared_ptr&, String const&, unsigned long)::'lambda3'()&&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::commitPart(std::shared_ptr const&, std::shared_ptr&, String const&, unsigned long)::'lambda3'()&&, void DB::ZooKeeperRetriesControl::retryLoop::commitPart(std::shared_ptr const&, std::shared_ptr&, String const&, unsigned long)::'lambda3'()>(DB::ReplicatedMergeTreeSinkImpl::commitPart(std::shared_ptr const&, std::shared_ptr&, String const&, unsigned long)::'lambda3'()&&)::'lambda'()&&) @ 0x000000001660d07f 7. /build/src/Common/ZooKeeper/ZooKeeperRetries.h:52: DB::ReplicatedMergeTreeSinkImpl::commitPart(std::shared_ptr const&, std::shared_ptr&, String const&, unsigned long) @ 0x00000000165fd951 8. /build/src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:492: DB::ReplicatedMergeTreeSinkImpl::finishDelayedChunk(std::shared_ptr const&) @ 0x00000000165f277d 9. /build/src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:437: DB::ReplicatedMergeTreeSinkImpl::consume(DB::Chunk&) @ 0x00000000165fbd00 10. /build/src/Processors/Sinks/SinkToStorage.cpp:10: DB::SinkToStorage::onConsume(DB::Chunk) @ 0x0000000016cee093 11. /build/src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: void std::__function::__policy_invoker::__call_impl[abi:se190107]>(std::__function::__policy_storage const*) @ 0x0000000016c0ad89 12. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000016c0abf5 13. /build/src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: DB::ExceptionKeepingTransform::work() @ 0x0000000016c0a6fe 14. /build/src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x00000000169bd00f 15. /build/src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x00000000169b2105 16. /build/src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeSingleThread(unsigned long) @ 0x00000000169b23be 17. /build/src/Processors/Executors/PipelineExecutor.cpp:416: void std::__function::__policy_invoker::__call_impl[abi:se190107]>(std::__function::__policy_storage const*) @ 0x00000000169b2e3f 18. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc6653 19. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000000fccc4c3 20. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc3d92 21. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fcca080 22. ? @ 0x00007fbc6213eac3 23. ? @ 0x00007fbc621d0850 2025.07.28 11:58:52.358224 [ 4446 ] {} TCPHandler: Code: 242. DB::Exception: Table is in readonly mode due to shutdown: replica_path=/clickhouse/tables/01103_optimize_drop_race_zookeeper_test_15/concurrent_optimize_table/replicas/1. (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000a9b78ab 4. /build/src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:866: DB::ReplicatedMergeTreeSinkImpl::commitPart(std::shared_ptr const&, std::shared_ptr&, String const&, unsigned long)::'lambda1'()::operator()() const @ 0x000000001660eed7 5. /build/src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:1124: DB::ReplicatedMergeTreeSinkImpl::commitPart(std::shared_ptr const&, std::shared_ptr&, String const&, unsigned long)::'lambda2'()::operator()() const @ 0x000000001660d1f2 6. /build/src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:1157: void DB::ZooKeeperRetriesControl::retryLoop::commitPart(std::shared_ptr const&, std::shared_ptr&, String const&, unsigned long)::'lambda3'()&, void DB::ZooKeeperRetriesControl::retryLoop::commitPart(std::shared_ptr const&, std::shared_ptr&, String const&, unsigned long)::'lambda3'()>(DB::ReplicatedMergeTreeSinkImpl::commitPart(std::shared_ptr const&, std::shared_ptr&, String const&, unsigned long)::'lambda3'()&&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::commitPart(std::shared_ptr const&, std::shared_ptr&, String const&, unsigned long)::'lambda3'()&&, void DB::ZooKeeperRetriesControl::retryLoop::commitPart(std::shared_ptr const&, std::shared_ptr&, String const&, unsigned long)::'lambda3'()>(DB::ReplicatedMergeTreeSinkImpl::commitPart(std::shared_ptr const&, std::shared_ptr&, String const&, unsigned long)::'lambda3'()&&)::'lambda'()&&) @ 0x000000001660d07f 7. /build/src/Common/ZooKeeper/ZooKeeperRetries.h:52: DB::ReplicatedMergeTreeSinkImpl::commitPart(std::shared_ptr const&, std::shared_ptr&, String const&, unsigned long) @ 0x00000000165fd951 8. /build/src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:492: DB::ReplicatedMergeTreeSinkImpl::finishDelayedChunk(std::shared_ptr const&) @ 0x00000000165f277d 9. /build/src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:437: DB::ReplicatedMergeTreeSinkImpl::consume(DB::Chunk&) @ 0x00000000165fbd00 10. /build/src/Processors/Sinks/SinkToStorage.cpp:10: DB::SinkToStorage::onConsume(DB::Chunk) @ 0x0000000016cee093 11. /build/src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: void std::__function::__policy_invoker::__call_impl[abi:se190107]>(std::__function::__policy_storage const*) @ 0x0000000016c0ad89 12. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000016c0abf5 13. /build/src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: DB::ExceptionKeepingTransform::work() @ 0x0000000016c0a6fe 14. /build/src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x00000000169bd00f 15. /build/src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x00000000169b2105 16. /build/src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeSingleThread(unsigned long) @ 0x00000000169b23be 17. /build/src/Processors/Executors/PipelineExecutor.cpp:416: void std::__function::__policy_invoker::__call_impl[abi:se190107]>(std::__function::__policy_storage const*) @ 0x00000000169b2e3f 18. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc6653 19. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000000fccc4c3 20. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc3d92 21. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fcca080 22. ? @ 0x00007fbc6213eac3 23. ? @ 0x00007fbc621d0850 Job's origin stack trace: 0. /build/src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000000fc33b84 1. /build/src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000000fcc2ea7 2. /build/src/Common/ThreadPool.cpp:401: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fcc7f1c 3. /build/src/Common/ThreadPool.cpp:494: ThreadPoolImpl>::scheduleOrThrowOnError(std::function, Priority) @ 0x000000000fcc7a0e 4. /build/src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::spawnThreadsImpl() @ 0x00000000169b2c0c 5. /build/src/Processors/Executors/PipelineExecutor.cpp:394: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x00000000169b0ba7 6. /build/src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x00000000169b03f4 7. /build/src/Processors/Executors/CompletedPipelineExecutor.cpp:42: void std::__function::__policy_invoker::__call_impl[abi:se190107]::ThreadFromGlobalPoolImpl(DB::CompletedPipelineExecutor::execute()::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169af7e1 8. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc3d92 9. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fcca080 10. ? @ 0x00007fbc6213eac3 11. ? @ 0x00007fbc621d0850 Job's origin stack trace: 0. /build/src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000000fc33b84 1. /build/src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000000fcc2ea7 2. /build/src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fcc535c 3. /build/src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000000fcc584d 4. /build/src/Common/ThreadPool.h:279: DB::CompletedPipelineExecutor::execute() @ 0x00000000169af267 5. /build/src/Server/TCPHandler.cpp:707: DB::TCPHandler::runImpl() @ 0x00000000168e6b2e 6. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 7. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 8. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 9. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 10. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 11. ? @ 0x00007fbc6213eac3 12. ? @ 0x00007fbc621d0850 2025.07.28 11:58:52.436712 [ 4581 ] {} TCPHandler: Code: 242. DB::Exception: Table is in readonly mode due to shutdown: replica_path=/clickhouse/tables/01103_optimize_drop_race_zookeeper_test_15/concurrent_optimize_table/replicas/1. (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000a9b78ab 4. /build/src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:866: DB::ReplicatedMergeTreeSinkImpl::commitPart(std::shared_ptr const&, std::shared_ptr&, String const&, unsigned long)::'lambda1'()::operator()() const @ 0x000000001660eed7 5. /build/src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:1124: DB::ReplicatedMergeTreeSinkImpl::commitPart(std::shared_ptr const&, std::shared_ptr&, String const&, unsigned long)::'lambda2'()::operator()() const @ 0x000000001660d1f2 6. /build/src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:1157: void DB::ZooKeeperRetriesControl::retryLoop::commitPart(std::shared_ptr const&, std::shared_ptr&, String const&, unsigned long)::'lambda3'()&, void DB::ZooKeeperRetriesControl::retryLoop::commitPart(std::shared_ptr const&, std::shared_ptr&, String const&, unsigned long)::'lambda3'()>(DB::ReplicatedMergeTreeSinkImpl::commitPart(std::shared_ptr const&, std::shared_ptr&, String const&, unsigned long)::'lambda3'()&&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::commitPart(std::shared_ptr const&, std::shared_ptr&, String const&, unsigned long)::'lambda3'()&&, void DB::ZooKeeperRetriesControl::retryLoop::commitPart(std::shared_ptr const&, std::shared_ptr&, String const&, unsigned long)::'lambda3'()>(DB::ReplicatedMergeTreeSinkImpl::commitPart(std::shared_ptr const&, std::shared_ptr&, String const&, unsigned long)::'lambda3'()&&)::'lambda'()&&) @ 0x000000001660d07f 7. /build/src/Common/ZooKeeper/ZooKeeperRetries.h:52: DB::ReplicatedMergeTreeSinkImpl::commitPart(std::shared_ptr const&, std::shared_ptr&, String const&, unsigned long) @ 0x00000000165fd951 8. /build/src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:492: DB::ReplicatedMergeTreeSinkImpl::finishDelayedChunk(std::shared_ptr const&) @ 0x00000000165f277d 9. /build/src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:437: DB::ReplicatedMergeTreeSinkImpl::consume(DB::Chunk&) @ 0x00000000165fbd00 10. /build/src/Processors/Sinks/SinkToStorage.cpp:10: DB::SinkToStorage::onConsume(DB::Chunk) @ 0x0000000016cee093 11. /build/src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: void std::__function::__policy_invoker::__call_impl[abi:se190107]>(std::__function::__policy_storage const*) @ 0x0000000016c0ad89 12. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000016c0abf5 13. /build/src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: DB::ExceptionKeepingTransform::work() @ 0x0000000016c0a6fe 14. /build/src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x00000000169bd00f 15. /build/src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x00000000169b2105 16. /build/src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeSingleThread(unsigned long) @ 0x00000000169b23be 17. /build/src/Processors/Executors/PipelineExecutor.cpp:416: void std::__function::__policy_invoker::__call_impl[abi:se190107]>(std::__function::__policy_storage const*) @ 0x00000000169b2e3f 18. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc6653 19. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000000fccc4c3 20. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc3d92 21. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fcca080 22. ? @ 0x00007fbc6213eac3 23. ? @ 0x00007fbc621d0850 Job's origin stack trace: 0. /build/src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000000fc33b84 1. /build/src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000000fcc2ea7 2. /build/src/Common/ThreadPool.cpp:401: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fcc7f1c 3. /build/src/Common/ThreadPool.cpp:494: ThreadPoolImpl>::scheduleOrThrowOnError(std::function, Priority) @ 0x000000000fcc7a0e 4. /build/src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::spawnThreadsImpl() @ 0x00000000169b2c0c 5. /build/src/Processors/Executors/PipelineExecutor.cpp:394: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x00000000169b0ba7 6. /build/src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x00000000169b03f4 7. /build/src/Processors/Executors/CompletedPipelineExecutor.cpp:42: void std::__function::__policy_invoker::__call_impl[abi:se190107]::ThreadFromGlobalPoolImpl(DB::CompletedPipelineExecutor::execute()::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169af7e1 8. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc3d92 9. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fcca080 10. ? @ 0x00007fbc6213eac3 11. ? @ 0x00007fbc621d0850 Job's origin stack trace: 0. /build/src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000000fc33b84 1. /build/src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000000fcc2ea7 2. /build/src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fcc535c 3. /build/src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000000fcc584d 4. /build/src/Common/ThreadPool.h:279: DB::CompletedPipelineExecutor::execute() @ 0x00000000169af267 5. /build/src/Server/TCPHandler.cpp:707: DB::TCPHandler::runImpl() @ 0x00000000168e6b2e 6. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 7. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 8. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 9. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 10. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 11. ? @ 0x00007fbc6213eac3 12. ? @ 0x00007fbc621d0850 2025.07.28 11:58:52.575287 [ 3287 ] {6c8b7e74-91d4-42b7-98ae-c0ce081abc87} executeQuery: Code: 60. DB::Exception: Table test_15.concurrent_optimize_table does not exist. (UNKNOWN_TABLE) (version 25.3.6.10636.altinitytest (altinity build)) (from [::1]:40016) (comment: 01103_optimize_drop_race_zookeeper.sh) (query 1, line 1) (in query: OPTIMIZE TABLE concurrent_optimize_table FINAL), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000a06a8eb 4. /build/src/Databases/IDatabase.cpp:41: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x0000000013dd565f 5. /build/src/Interpreters/DatabaseCatalog.cpp:442: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x00000000144f0869 6. /build/src/Interpreters/DatabaseCatalog.cpp:976: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x00000000144f6c88 7. /build/src/Interpreters/InterpreterOptimizeQuery.cpp:40: DB::InterpreterOptimizeQuery::execute() @ 0x0000000014cd71de 8. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88dc9 9. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 10. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 11. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 12. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 13. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 14. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 15. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 16. ? @ 0x00007fbc6213eac3 17. ? @ 0x00007fbc621d0850 2025.07.28 11:58:52.594741 [ 3287 ] {} TCPHandler: Code: 60. DB::Exception: Table test_15.concurrent_optimize_table does not exist. (UNKNOWN_TABLE), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000a06a8eb 4. /build/src/Databases/IDatabase.cpp:41: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x0000000013dd565f 5. /build/src/Interpreters/DatabaseCatalog.cpp:442: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x00000000144f0869 6. /build/src/Interpreters/DatabaseCatalog.cpp:976: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x00000000144f6c88 7. /build/src/Interpreters/InterpreterOptimizeQuery.cpp:40: DB::InterpreterOptimizeQuery::execute() @ 0x0000000014cd71de 8. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88dc9 9. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 10. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 11. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 12. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 13. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 14. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 15. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 16. ? @ 0x00007fbc6213eac3 17. ? @ 0x00007fbc621d0850 2025.07.28 11:58:52.601115 [ 17208 ] {727d667e-e4bf-472e-bf01-c738e4f3ee76} executeQuery: Code: 60. DB::Exception: Table test_15.concurrent_optimize_table does not exist. (UNKNOWN_TABLE) (version 25.3.6.10636.altinitytest (altinity build)) (from [::1]:40026) (comment: 01103_optimize_drop_race_zookeeper.sh) (query 1, line 1) (in query: INSERT INTO concurrent_optimize_table SELECT rand(1), rand(2), 1 / rand(3), toString(rand(4)), [rand(5), rand(6)], rand(7) % 2 ? NULL : generateUUIDv4(), (rand(8), rand(9)) FROM numbers(10000)), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000a06a8eb 4. /build/src/Databases/IDatabase.cpp:41: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x0000000013dd565f 5. /build/src/Interpreters/DatabaseCatalog.cpp:442: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x00000000144f0869 6. /build/src/Interpreters/DatabaseCatalog.cpp:976: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x00000000144f6c88 7. /build/src/Interpreters/InterpreterInsertQuery.cpp:169: DB::InterpreterInsertQuery::getTable(DB::ASTInsertQuery&) @ 0x000000001492bf04 8. /build/src/Interpreters/InterpreterInsertQuery.cpp:829: DB::InterpreterInsertQuery::execute() @ 0x0000000014933938 9. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88dc9 10. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 11. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 12. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 13. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 14. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 16. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 17. ? @ 0x00007fbc6213eac3 18. ? @ 0x00007fbc621d0850 2025.07.28 11:58:52.633442 [ 4581 ] {799a7480-2e10-4765-bcc8-a0313ec3fe39} executeQuery: Code: 60. DB::Exception: Table test_15.concurrent_optimize_table does not exist. (UNKNOWN_TABLE) (version 25.3.6.10636.altinitytest (altinity build)) (from [::1]:40018) (comment: 01103_optimize_drop_race_zookeeper.sh) (query 1, line 1) (in query: INSERT INTO concurrent_optimize_table SELECT rand(1), rand(2), 1 / rand(3), toString(rand(4)), [rand(5), rand(6)], rand(7) % 2 ? NULL : generateUUIDv4(), (rand(8), rand(9)) FROM numbers(10000)), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000a06a8eb 4. /build/src/Databases/IDatabase.cpp:41: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x0000000013dd565f 5. /build/src/Interpreters/DatabaseCatalog.cpp:442: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x00000000144f0869 6. /build/src/Interpreters/DatabaseCatalog.cpp:976: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x00000000144f6c88 7. /build/src/Interpreters/InterpreterInsertQuery.cpp:169: DB::InterpreterInsertQuery::getTable(DB::ASTInsertQuery&) @ 0x000000001492bf04 8. /build/src/Interpreters/InterpreterInsertQuery.cpp:829: DB::InterpreterInsertQuery::execute() @ 0x0000000014933938 9. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88dc9 10. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 11. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 12. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 13. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 14. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 16. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 17. ? @ 0x00007fbc6213eac3 18. ? @ 0x00007fbc621d0850 2025.07.28 11:58:52.634936 [ 17208 ] {} TCPHandler: Code: 60. DB::Exception: Table test_15.concurrent_optimize_table does not exist. (UNKNOWN_TABLE), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000a06a8eb 4. /build/src/Databases/IDatabase.cpp:41: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x0000000013dd565f 5. /build/src/Interpreters/DatabaseCatalog.cpp:442: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x00000000144f0869 6. /build/src/Interpreters/DatabaseCatalog.cpp:976: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x00000000144f6c88 7. /build/src/Interpreters/InterpreterInsertQuery.cpp:169: DB::InterpreterInsertQuery::getTable(DB::ASTInsertQuery&) @ 0x000000001492bf04 8. /build/src/Interpreters/InterpreterInsertQuery.cpp:829: DB::InterpreterInsertQuery::execute() @ 0x0000000014933938 9. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88dc9 10. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 11. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 12. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 13. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 14. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 16. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 17. ? @ 0x00007fbc6213eac3 18. ? @ 0x00007fbc621d0850 2025.07.28 11:58:52.662938 [ 4581 ] {} TCPHandler: Code: 60. DB::Exception: Table test_15.concurrent_optimize_table does not exist. (UNKNOWN_TABLE), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000a06a8eb 4. /build/src/Databases/IDatabase.cpp:41: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x0000000013dd565f 5. /build/src/Interpreters/DatabaseCatalog.cpp:442: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x00000000144f0869 6. /build/src/Interpreters/DatabaseCatalog.cpp:976: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x00000000144f6c88 7. /build/src/Interpreters/InterpreterInsertQuery.cpp:169: DB::InterpreterInsertQuery::getTable(DB::ASTInsertQuery&) @ 0x000000001492bf04 8. /build/src/Interpreters/InterpreterInsertQuery.cpp:829: DB::InterpreterInsertQuery::execute() @ 0x0000000014933938 9. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88dc9 10. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 11. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 12. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 13. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 14. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 16. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 17. ? @ 0x00007fbc6213eac3 18. ? @ 0x00007fbc621d0850 2025.07.28 11:58:52.695906 [ 5327 ] {76c0af48-ebe4-4136-a58f-294049f196c8} executeQuery: Code: 242. DB::Exception: Table is in readonly mode due to shutdown: replica_path=/clickhouse/tables/01103_optimize_drop_race_zookeeper_test_15/concurrent_optimize_table/replicas/1. (TABLE_IS_READ_ONLY) (version 25.3.6.10636.altinitytest (altinity build)) (from [::1]:39908) (comment: 01103_optimize_drop_race_zookeeper.sh) (query 1, line 1) (in query: INSERT INTO concurrent_optimize_table SELECT rand(1), rand(2), 1 / rand(3), toString(rand(4)), [rand(5), rand(6)], rand(7) % 2 ? NULL : generateUUIDv4(), (rand(8), rand(9)) FROM numbers(10000)), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000a9b78ab 4. /build/src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:866: DB::ReplicatedMergeTreeSinkImpl::commitPart(std::shared_ptr const&, std::shared_ptr&, String const&, unsigned long)::'lambda1'()::operator()() const @ 0x000000001660eed7 5. /build/src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:1124: DB::ReplicatedMergeTreeSinkImpl::commitPart(std::shared_ptr const&, std::shared_ptr&, String const&, unsigned long)::'lambda2'()::operator()() const @ 0x000000001660d1f2 6. /build/src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:1157: void DB::ZooKeeperRetriesControl::retryLoop::commitPart(std::shared_ptr const&, std::shared_ptr&, String const&, unsigned long)::'lambda3'()&, void DB::ZooKeeperRetriesControl::retryLoop::commitPart(std::shared_ptr const&, std::shared_ptr&, String const&, unsigned long)::'lambda3'()>(DB::ReplicatedMergeTreeSinkImpl::commitPart(std::shared_ptr const&, std::shared_ptr&, String const&, unsigned long)::'lambda3'()&&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::commitPart(std::shared_ptr const&, std::shared_ptr&, String const&, unsigned long)::'lambda3'()&&, void DB::ZooKeeperRetriesControl::retryLoop::commitPart(std::shared_ptr const&, std::shared_ptr&, String const&, unsigned long)::'lambda3'()>(DB::ReplicatedMergeTreeSinkImpl::commitPart(std::shared_ptr const&, std::shared_ptr&, String const&, unsigned long)::'lambda3'()&&)::'lambda'()&&) @ 0x000000001660d07f 7. /build/src/Common/ZooKeeper/ZooKeeperRetries.h:52: DB::ReplicatedMergeTreeSinkImpl::commitPart(std::shared_ptr const&, std::shared_ptr&, String const&, unsigned long) @ 0x00000000165fd951 8. /build/src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:492: DB::ReplicatedMergeTreeSinkImpl::finishDelayedChunk(std::shared_ptr const&) @ 0x00000000165f277d 9. /build/src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:437: DB::ReplicatedMergeTreeSinkImpl::consume(DB::Chunk&) @ 0x00000000165fbd00 10. /build/src/Processors/Sinks/SinkToStorage.cpp:10: DB::SinkToStorage::onConsume(DB::Chunk) @ 0x0000000016cee093 11. /build/src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: void std::__function::__policy_invoker::__call_impl[abi:se190107]>(std::__function::__policy_storage const*) @ 0x0000000016c0ad89 12. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000016c0abf5 13. /build/src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: DB::ExceptionKeepingTransform::work() @ 0x0000000016c0a6fe 14. /build/src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x00000000169bd00f 15. /build/src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x00000000169b2105 16. /build/src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeSingleThread(unsigned long) @ 0x00000000169b23be 17. /build/src/Processors/Executors/PipelineExecutor.cpp:416: void std::__function::__policy_invoker::__call_impl[abi:se190107]>(std::__function::__policy_storage const*) @ 0x00000000169b2e3f 18. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc6653 19. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000000fccc4c3 20. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc3d92 21. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fcca080 22. ? @ 0x00007fbc6213eac3 23. ? @ 0x00007fbc621d0850 2025.07.28 11:58:52.695960 [ 17191 ] {10fc0217-94cc-4874-bc84-710a63e2d307} executeQuery: Code: 242. DB::Exception: Table is in readonly mode due to shutdown: replica_path=/clickhouse/tables/01103_optimize_drop_race_zookeeper_test_15/concurrent_optimize_table/replicas/1. (TABLE_IS_READ_ONLY) (version 25.3.6.10636.altinitytest (altinity build)) (from [::1]:39922) (comment: 01103_optimize_drop_race_zookeeper.sh) (query 1, line 1) (in query: INSERT INTO concurrent_optimize_table SELECT rand(1), rand(2), 1 / rand(3), toString(rand(4)), [rand(5), rand(6)], rand(7) % 2 ? NULL : generateUUIDv4(), (rand(8), rand(9)) FROM numbers(10000)), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000a9b78ab 4. /build/src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:866: DB::ReplicatedMergeTreeSinkImpl::commitPart(std::shared_ptr const&, std::shared_ptr&, String const&, unsigned long)::'lambda1'()::operator()() const @ 0x000000001660eed7 5. /build/src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:1124: DB::ReplicatedMergeTreeSinkImpl::commitPart(std::shared_ptr const&, std::shared_ptr&, String const&, unsigned long)::'lambda2'()::operator()() const @ 0x000000001660d1f2 6. /build/src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:1157: void DB::ZooKeeperRetriesControl::retryLoop::commitPart(std::shared_ptr const&, std::shared_ptr&, String const&, unsigned long)::'lambda3'()&, void DB::ZooKeeperRetriesControl::retryLoop::commitPart(std::shared_ptr const&, std::shared_ptr&, String const&, unsigned long)::'lambda3'()>(DB::ReplicatedMergeTreeSinkImpl::commitPart(std::shared_ptr const&, std::shared_ptr&, String const&, unsigned long)::'lambda3'()&&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::commitPart(std::shared_ptr const&, std::shared_ptr&, String const&, unsigned long)::'lambda3'()&&, void DB::ZooKeeperRetriesControl::retryLoop::commitPart(std::shared_ptr const&, std::shared_ptr&, String const&, unsigned long)::'lambda3'()>(DB::ReplicatedMergeTreeSinkImpl::commitPart(std::shared_ptr const&, std::shared_ptr&, String const&, unsigned long)::'lambda3'()&&)::'lambda'()&&) @ 0x000000001660d07f 7. /build/src/Common/ZooKeeper/ZooKeeperRetries.h:52: DB::ReplicatedMergeTreeSinkImpl::commitPart(std::shared_ptr const&, std::shared_ptr&, String const&, unsigned long) @ 0x00000000165fd951 8. /build/src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:492: DB::ReplicatedMergeTreeSinkImpl::finishDelayedChunk(std::shared_ptr const&) @ 0x00000000165f277d 9. /build/src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:437: DB::ReplicatedMergeTreeSinkImpl::consume(DB::Chunk&) @ 0x00000000165fbd00 10. /build/src/Processors/Sinks/SinkToStorage.cpp:10: DB::SinkToStorage::onConsume(DB::Chunk) @ 0x0000000016cee093 11. /build/src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: void std::__function::__policy_invoker::__call_impl[abi:se190107]>(std::__function::__policy_storage const*) @ 0x0000000016c0ad89 12. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000016c0abf5 13. /build/src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: DB::ExceptionKeepingTransform::work() @ 0x0000000016c0a6fe 14. /build/src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x00000000169bd00f 15. /build/src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x00000000169b2105 16. /build/src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeSingleThread(unsigned long) @ 0x00000000169b23be 17. /build/src/Processors/Executors/PipelineExecutor.cpp:416: void std::__function::__policy_invoker::__call_impl[abi:se190107]>(std::__function::__policy_storage const*) @ 0x00000000169b2e3f 18. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc6653 19. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000000fccc4c3 20. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc3d92 21. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fcca080 22. ? @ 0x00007fbc6213eac3 23. ? @ 0x00007fbc621d0850 2025.07.28 11:58:52.706695 [ 3966 ] {} test_13.rmt2 (7f9b740d-015c-470e-8cc6-8ba33be0dc63): auto DB::StorageReplicatedMergeTree::processQueueEntry(ReplicatedMergeTreeQueue::SelectedEntryPtr)::(anonymous class)::operator()(LogEntryPtr &) const: Code: 86. DB::HTTPException: Received error from remote server http://146b4357c08d:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Ftest%2F01165%2Ftest_13%2Frmt%2Freplicas%2F1&part=20250728_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.6.10636.altinitytest (altinity build)) '. (RECEIVED_ERROR_FROM_REMOTE_IO_SERVER), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.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 const&, int&&, String const&, unsigned long&&, String const&) @ 0x000000000feda8d9 4. /build/src/IO/HTTPCommon.cpp:104: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x000000000feda6e2 5. /build/src/IO/HTTPCommon.cpp:93: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x000000000feda537 6. /build/src/IO/ReadWriteBufferFromHTTP.cpp:277: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x000000001184a4c4 7. /build/src/IO/ReadWriteBufferFromHTTP.cpp:285: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x000000001184a615 8. /build/src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x000000001184ae59 9. /build/src/IO/ReadWriteBufferFromHTTP.cpp:472: void std::__function::__policy_invoker::__call_impl[abi:se190107]>(std::__function::__policy_storage const*) @ 0x000000001184cedd 10. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001184858b 11. /build/src/IO/ReadWriteBufferFromHTTP.cpp:465: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x000000001184bf0b 12. /build/src/IO/ReadBuffer.h:60: DB::ReadBuffer::next() @ 0x000000000a148c7b 13. /build/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) @ 0x0000000011849fb2 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]>&)>&, 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&) @ 0x0000000011841980 15. /build/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) @ 0x000000001621208e 16. /build/src/Storages/StorageReplicatedMergeTree.cpp:5228: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl[abi:se190107] const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000015f9a5fe 17. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000015ed8bfd 18. /build/src/Storages/StorageReplicatedMergeTree.cpp:2514: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x0000000015ec9aab 19. /build/src/Storages/StorageReplicatedMergeTree.cpp:2349: DB::StorageReplicatedMergeTree::executeLogEntry(DB::ReplicatedMergeTreeLogEntry&) @ 0x0000000015eba91b 20. /build/src/Storages/StorageReplicatedMergeTree.cpp:3876: bool std::__function::__policy_invoker&)>::__call_impl[abi:se190107])::$_1, bool (std::shared_ptr&)>>(std::__function::__policy_storage const*, std::shared_ptr&) @ 0x0000000015f9837e 21. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000165d6fc3 22. /build/src/Storages/StorageReplicatedMergeTree.cpp:3872: DB::StorageReplicatedMergeTree::processQueueEntry(std::shared_ptr) @ 0x0000000015efc18a 23. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001624c1b2 24. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000162f9c70 25. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x00000000162fa55a 26. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc6653 27. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000000fccc4c3 28. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc3d92 29. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fcca080 30. ? @ 0x00007fbc6213eac3 31. ? @ 0x00007fbc621d0850 (version 25.3.6.10636.altinitytest (altinity build)) 2025.07.28 11:58:52.738433 [ 5327 ] {} TCPHandler: Code: 242. DB::Exception: Table is in readonly mode due to shutdown: replica_path=/clickhouse/tables/01103_optimize_drop_race_zookeeper_test_15/concurrent_optimize_table/replicas/1. (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000a9b78ab 4. /build/src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:866: DB::ReplicatedMergeTreeSinkImpl::commitPart(std::shared_ptr const&, std::shared_ptr&, String const&, unsigned long)::'lambda1'()::operator()() const @ 0x000000001660eed7 5. /build/src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:1124: DB::ReplicatedMergeTreeSinkImpl::commitPart(std::shared_ptr const&, std::shared_ptr&, String const&, unsigned long)::'lambda2'()::operator()() const @ 0x000000001660d1f2 6. /build/src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:1157: void DB::ZooKeeperRetriesControl::retryLoop::commitPart(std::shared_ptr const&, std::shared_ptr&, String const&, unsigned long)::'lambda3'()&, void DB::ZooKeeperRetriesControl::retryLoop::commitPart(std::shared_ptr const&, std::shared_ptr&, String const&, unsigned long)::'lambda3'()>(DB::ReplicatedMergeTreeSinkImpl::commitPart(std::shared_ptr const&, std::shared_ptr&, String const&, unsigned long)::'lambda3'()&&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::commitPart(std::shared_ptr const&, std::shared_ptr&, String const&, unsigned long)::'lambda3'()&&, void DB::ZooKeeperRetriesControl::retryLoop::commitPart(std::shared_ptr const&, std::shared_ptr&, String const&, unsigned long)::'lambda3'()>(DB::ReplicatedMergeTreeSinkImpl::commitPart(std::shared_ptr const&, std::shared_ptr&, String const&, unsigned long)::'lambda3'()&&)::'lambda'()&&) @ 0x000000001660d07f 7. /build/src/Common/ZooKeeper/ZooKeeperRetries.h:52: DB::ReplicatedMergeTreeSinkImpl::commitPart(std::shared_ptr const&, std::shared_ptr&, String const&, unsigned long) @ 0x00000000165fd951 8. /build/src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:492: DB::ReplicatedMergeTreeSinkImpl::finishDelayedChunk(std::shared_ptr const&) @ 0x00000000165f277d 9. /build/src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:437: DB::ReplicatedMergeTreeSinkImpl::consume(DB::Chunk&) @ 0x00000000165fbd00 10. /build/src/Processors/Sinks/SinkToStorage.cpp:10: DB::SinkToStorage::onConsume(DB::Chunk) @ 0x0000000016cee093 11. /build/src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: void std::__function::__policy_invoker::__call_impl[abi:se190107]>(std::__function::__policy_storage const*) @ 0x0000000016c0ad89 12. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000016c0abf5 13. /build/src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: DB::ExceptionKeepingTransform::work() @ 0x0000000016c0a6fe 14. /build/src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x00000000169bd00f 15. /build/src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x00000000169b2105 16. /build/src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeSingleThread(unsigned long) @ 0x00000000169b23be 17. /build/src/Processors/Executors/PipelineExecutor.cpp:416: void std::__function::__policy_invoker::__call_impl[abi:se190107]>(std::__function::__policy_storage const*) @ 0x00000000169b2e3f 18. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc6653 19. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000000fccc4c3 20. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc3d92 21. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fcca080 22. ? @ 0x00007fbc6213eac3 23. ? @ 0x00007fbc621d0850 Job's origin stack trace: 0. /build/src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000000fc33b84 1. /build/src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000000fcc2ea7 2. /build/src/Common/ThreadPool.cpp:401: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fcc7f1c 3. /build/src/Common/ThreadPool.cpp:494: ThreadPoolImpl>::scheduleOrThrowOnError(std::function, Priority) @ 0x000000000fcc7a0e 4. /build/src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::spawnThreadsImpl() @ 0x00000000169b2c0c 5. /build/src/Processors/Executors/PipelineExecutor.cpp:394: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x00000000169b0ba7 6. /build/src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x00000000169b03f4 7. /build/src/Processors/Executors/CompletedPipelineExecutor.cpp:42: void std::__function::__policy_invoker::__call_impl[abi:se190107]::ThreadFromGlobalPoolImpl(DB::CompletedPipelineExecutor::execute()::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169af7e1 8. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc3d92 9. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fcca080 10. ? @ 0x00007fbc6213eac3 11. ? @ 0x00007fbc621d0850 Job's origin stack trace: 0. /build/src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000000fc33b84 1. /build/src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000000fcc2ea7 2. /build/src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fcc535c 3. /build/src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000000fcc584d 4. /build/src/Common/ThreadPool.h:279: DB::CompletedPipelineExecutor::execute() @ 0x00000000169af267 5. /build/src/Server/TCPHandler.cpp:707: DB::TCPHandler::runImpl() @ 0x00000000168e6b2e 6. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 7. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 8. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 9. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 10. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 11. ? @ 0x00007fbc6213eac3 12. ? @ 0x00007fbc621d0850 2025.07.28 11:58:52.742705 [ 3285 ] {0fe10745-5bd6-451f-99cd-33dd4304185e} executeQuery: Code: 60. DB::Exception: Table test_15.concurrent_optimize_table does not exist. (UNKNOWN_TABLE) (version 25.3.6.10636.altinitytest (altinity build)) (from [::1]:40040) (comment: 01103_optimize_drop_race_zookeeper.sh) (query 1, line 1) (in query: OPTIMIZE TABLE concurrent_optimize_table FINAL), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000a06a8eb 4. /build/src/Databases/IDatabase.cpp:41: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x0000000013dd565f 5. /build/src/Interpreters/DatabaseCatalog.cpp:442: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x00000000144f0869 6. /build/src/Interpreters/DatabaseCatalog.cpp:976: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x00000000144f6c88 7. /build/src/Interpreters/InterpreterOptimizeQuery.cpp:40: DB::InterpreterOptimizeQuery::execute() @ 0x0000000014cd71de 8. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88dc9 9. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 10. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 11. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 12. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 13. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 14. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 15. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 16. ? @ 0x00007fbc6213eac3 17. ? @ 0x00007fbc621d0850 2025.07.28 11:58:52.758051 [ 3285 ] {} TCPHandler: Code: 60. DB::Exception: Table test_15.concurrent_optimize_table does not exist. (UNKNOWN_TABLE), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000a06a8eb 4. /build/src/Databases/IDatabase.cpp:41: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x0000000013dd565f 5. /build/src/Interpreters/DatabaseCatalog.cpp:442: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x00000000144f0869 6. /build/src/Interpreters/DatabaseCatalog.cpp:976: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x00000000144f6c88 7. /build/src/Interpreters/InterpreterOptimizeQuery.cpp:40: DB::InterpreterOptimizeQuery::execute() @ 0x0000000014cd71de 8. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88dc9 9. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 10. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 11. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 12. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 13. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 14. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 15. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 16. ? @ 0x00007fbc6213eac3 17. ? @ 0x00007fbc621d0850 2025.07.28 11:58:52.786938 [ 17191 ] {} TCPHandler: Code: 242. DB::Exception: Table is in readonly mode due to shutdown: replica_path=/clickhouse/tables/01103_optimize_drop_race_zookeeper_test_15/concurrent_optimize_table/replicas/1. (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000a9b78ab 4. /build/src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:866: DB::ReplicatedMergeTreeSinkImpl::commitPart(std::shared_ptr const&, std::shared_ptr&, String const&, unsigned long)::'lambda1'()::operator()() const @ 0x000000001660eed7 5. /build/src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:1124: DB::ReplicatedMergeTreeSinkImpl::commitPart(std::shared_ptr const&, std::shared_ptr&, String const&, unsigned long)::'lambda2'()::operator()() const @ 0x000000001660d1f2 6. /build/src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:1157: void DB::ZooKeeperRetriesControl::retryLoop::commitPart(std::shared_ptr const&, std::shared_ptr&, String const&, unsigned long)::'lambda3'()&, void DB::ZooKeeperRetriesControl::retryLoop::commitPart(std::shared_ptr const&, std::shared_ptr&, String const&, unsigned long)::'lambda3'()>(DB::ReplicatedMergeTreeSinkImpl::commitPart(std::shared_ptr const&, std::shared_ptr&, String const&, unsigned long)::'lambda3'()&&)::'lambda'()>(DB::ReplicatedMergeTreeSinkImpl::commitPart(std::shared_ptr const&, std::shared_ptr&, String const&, unsigned long)::'lambda3'()&&, void DB::ZooKeeperRetriesControl::retryLoop::commitPart(std::shared_ptr const&, std::shared_ptr&, String const&, unsigned long)::'lambda3'()>(DB::ReplicatedMergeTreeSinkImpl::commitPart(std::shared_ptr const&, std::shared_ptr&, String const&, unsigned long)::'lambda3'()&&)::'lambda'()&&) @ 0x000000001660d07f 7. /build/src/Common/ZooKeeper/ZooKeeperRetries.h:52: DB::ReplicatedMergeTreeSinkImpl::commitPart(std::shared_ptr const&, std::shared_ptr&, String const&, unsigned long) @ 0x00000000165fd951 8. /build/src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:492: DB::ReplicatedMergeTreeSinkImpl::finishDelayedChunk(std::shared_ptr const&) @ 0x00000000165f277d 9. /build/src/Storages/MergeTree/ReplicatedMergeTreeSink.cpp:437: DB::ReplicatedMergeTreeSinkImpl::consume(DB::Chunk&) @ 0x00000000165fbd00 10. /build/src/Processors/Sinks/SinkToStorage.cpp:10: DB::SinkToStorage::onConsume(DB::Chunk) @ 0x0000000016cee093 11. /build/src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: void std::__function::__policy_invoker::__call_impl[abi:se190107]>(std::__function::__policy_storage const*) @ 0x0000000016c0ad89 12. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000016c0abf5 13. /build/src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: DB::ExceptionKeepingTransform::work() @ 0x0000000016c0a6fe 14. /build/src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x00000000169bd00f 15. /build/src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x00000000169b2105 16. /build/src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeSingleThread(unsigned long) @ 0x00000000169b23be 17. /build/src/Processors/Executors/PipelineExecutor.cpp:416: void std::__function::__policy_invoker::__call_impl[abi:se190107]>(std::__function::__policy_storage const*) @ 0x00000000169b2e3f 18. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc6653 19. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000000fccc4c3 20. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc3d92 21. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fcca080 22. ? @ 0x00007fbc6213eac3 23. ? @ 0x00007fbc621d0850 Job's origin stack trace: 0. /build/src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000000fc33b84 1. /build/src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000000fcc2ea7 2. /build/src/Common/ThreadPool.cpp:401: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fcc7f1c 3. /build/src/Common/ThreadPool.cpp:494: ThreadPoolImpl>::scheduleOrThrowOnError(std::function, Priority) @ 0x000000000fcc7a0e 4. /build/src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::spawnThreadsImpl() @ 0x00000000169b2c0c 5. /build/src/Processors/Executors/PipelineExecutor.cpp:394: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x00000000169b0ba7 6. /build/src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x00000000169b03f4 7. /build/src/Processors/Executors/CompletedPipelineExecutor.cpp:42: void std::__function::__policy_invoker::__call_impl[abi:se190107]::ThreadFromGlobalPoolImpl(DB::CompletedPipelineExecutor::execute()::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169af7e1 8. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc3d92 9. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fcca080 10. ? @ 0x00007fbc6213eac3 11. ? @ 0x00007fbc621d0850 Job's origin stack trace: 0. /build/src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000000fc33b84 1. /build/src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000000fcc2ea7 2. /build/src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fcc535c 3. /build/src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000000fcc584d 4. /build/src/Common/ThreadPool.h:279: DB::CompletedPipelineExecutor::execute() @ 0x00000000169af267 5. /build/src/Server/TCPHandler.cpp:707: DB::TCPHandler::runImpl() @ 0x00000000168e6b2e 6. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 7. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 8. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 9. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 10. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 11. ? @ 0x00007fbc6213eac3 12. ? @ 0x00007fbc621d0850 2025.07.28 11:58:52.786009 [ 4963 ] {39fef095-c95b-481d-9ba3-08e48acc68a9} executeQuery: Code: 60. DB::Exception: Table test_15.concurrent_optimize_table does not exist. (UNKNOWN_TABLE) (version 25.3.6.10636.altinitytest (altinity build)) (from [::1]:40028) (comment: 01103_optimize_drop_race_zookeeper.sh) (query 1, line 1) (in query: OPTIMIZE TABLE concurrent_optimize_table FINAL), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000a06a8eb 4. /build/src/Databases/IDatabase.cpp:41: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x0000000013dd565f 5. /build/src/Interpreters/DatabaseCatalog.cpp:442: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x00000000144f0869 6. /build/src/Interpreters/DatabaseCatalog.cpp:976: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x00000000144f6c88 7. /build/src/Interpreters/InterpreterOptimizeQuery.cpp:40: DB::InterpreterOptimizeQuery::execute() @ 0x0000000014cd71de 8. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88dc9 9. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 10. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 11. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 12. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 13. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 14. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 15. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 16. ? @ 0x00007fbc6213eac3 17. ? @ 0x00007fbc621d0850 2025.07.28 11:58:52.809708 [ 4963 ] {} TCPHandler: Code: 60. DB::Exception: Table test_15.concurrent_optimize_table does not exist. (UNKNOWN_TABLE), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000a06a8eb 4. /build/src/Databases/IDatabase.cpp:41: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x0000000013dd565f 5. /build/src/Interpreters/DatabaseCatalog.cpp:442: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x00000000144f0869 6. /build/src/Interpreters/DatabaseCatalog.cpp:976: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x00000000144f6c88 7. /build/src/Interpreters/InterpreterOptimizeQuery.cpp:40: DB::InterpreterOptimizeQuery::execute() @ 0x0000000014cd71de 8. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88dc9 9. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 10. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 11. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 12. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 13. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 14. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 15. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 16. ? @ 0x00007fbc6213eac3 17. ? @ 0x00007fbc621d0850 2025.07.28 11:58:52.991675 [ 5879 ] {271d1097-7b17-44e6-8a9c-4fee60168869} executeQuery: Code: 60. DB::Exception: Table test_15.concurrent_optimize_table does not exist. (UNKNOWN_TABLE) (version 25.3.6.10636.altinitytest (altinity build)) (from [::1]:40054) (comment: 01103_optimize_drop_race_zookeeper.sh) (query 1, line 1) (in query: OPTIMIZE TABLE concurrent_optimize_table FINAL), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000a06a8eb 4. /build/src/Databases/IDatabase.cpp:41: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x0000000013dd565f 5. /build/src/Interpreters/DatabaseCatalog.cpp:442: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x00000000144f0869 6. /build/src/Interpreters/DatabaseCatalog.cpp:976: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x00000000144f6c88 7. /build/src/Interpreters/InterpreterOptimizeQuery.cpp:40: DB::InterpreterOptimizeQuery::execute() @ 0x0000000014cd71de 8. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88dc9 9. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 10. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 11. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 12. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 13. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 14. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 15. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 16. ? @ 0x00007fbc6213eac3 17. ? @ 0x00007fbc621d0850 2025.07.28 11:58:52.994649 [ 5879 ] {271d1097-7b17-44e6-8a9c-4fee60168869} 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]:40054). (NETWORK_ERROR), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::NetException::NetException(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&) @ 0x000000000fd50fb5 3. /build/src/IO/WriteBufferFromPocoSocket.cpp:171: DB::WriteBufferFromPocoSocket::nextImpl() @ 0x000000000fd525a7 4. /build/src/IO/WriteBuffer.h:53: DB::WriteBuffer::next() @ 0x000000000a0755be 5. /build/src/Server/TCPHandler.cpp:826: DB::TCPHandler::runImpl() @ 0x00000000168e6c9c 6. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 7. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 8. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 9. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 10. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 11. ? @ 0x00007fbc6213eac3 12. ? @ 0x00007fbc621d0850 (version 25.3.6.10636.altinitytest (altinity build)) 2025.07.28 11:58:52.995857 [ 5879 ] {} TCPHandler: Code: 60. DB::Exception: Table test_15.concurrent_optimize_table does not exist. (UNKNOWN_TABLE), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000a06a8eb 4. /build/src/Databases/IDatabase.cpp:41: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x0000000013dd565f 5. /build/src/Interpreters/DatabaseCatalog.cpp:442: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x00000000144f0869 6. /build/src/Interpreters/DatabaseCatalog.cpp:976: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x00000000144f6c88 7. /build/src/Interpreters/InterpreterOptimizeQuery.cpp:40: DB::InterpreterOptimizeQuery::execute() @ 0x0000000014cd71de 8. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88dc9 9. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 10. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 11. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 12. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 13. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 14. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 15. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 16. ? @ 0x00007fbc6213eac3 17. ? @ 0x00007fbc621d0850 2025.07.28 11:58:53.008284 [ 17191 ] {c85cb748-c07f-4011-aac6-9b1fd4d04a3e} executeQuery: Code: 60. DB::Exception: Table test_15.concurrent_optimize_table does not exist. (UNKNOWN_TABLE) (version 25.3.6.10636.altinitytest (altinity build)) (from [::1]:40098) (comment: 01103_optimize_drop_race_zookeeper.sh) (query 1, line 1) (in query: INSERT INTO concurrent_optimize_table SELECT rand(1), rand(2), 1 / rand(3), toString(rand(4)), [rand(5), rand(6)], rand(7) % 2 ? NULL : generateUUIDv4(), (rand(8), rand(9)) FROM numbers(10000)), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000a06a8eb 4. /build/src/Databases/IDatabase.cpp:41: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x0000000013dd565f 5. /build/src/Interpreters/DatabaseCatalog.cpp:442: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x00000000144f0869 6. /build/src/Interpreters/DatabaseCatalog.cpp:976: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x00000000144f6c88 7. /build/src/Interpreters/InterpreterInsertQuery.cpp:169: DB::InterpreterInsertQuery::getTable(DB::ASTInsertQuery&) @ 0x000000001492bf04 8. /build/src/Interpreters/InterpreterInsertQuery.cpp:829: DB::InterpreterInsertQuery::execute() @ 0x0000000014933938 9. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88dc9 10. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 11. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 12. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 13. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 14. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 16. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 17. ? @ 0x00007fbc6213eac3 18. ? @ 0x00007fbc621d0850 2025.07.28 11:58:53.008424 [ 17232 ] {454c43b8-9e8b-4d37-99eb-99d0fb6fbe06} executeQuery: Code: 60. DB::Exception: Table test_15.concurrent_optimize_table does not exist. (UNKNOWN_TABLE) (version 25.3.6.10636.altinitytest (altinity build)) (from [::1]:40114) (comment: 01103_optimize_drop_race_zookeeper.sh) (query 1, line 1) (in query: INSERT INTO concurrent_optimize_table SELECT rand(1), rand(2), 1 / rand(3), toString(rand(4)), [rand(5), rand(6)], rand(7) % 2 ? NULL : generateUUIDv4(), (rand(8), rand(9)) FROM numbers(10000)), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000a06a8eb 4. /build/src/Databases/IDatabase.cpp:41: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x0000000013dd565f 5. /build/src/Interpreters/DatabaseCatalog.cpp:442: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x00000000144f0869 6. /build/src/Interpreters/DatabaseCatalog.cpp:976: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x00000000144f6c88 7. /build/src/Interpreters/InterpreterInsertQuery.cpp:169: DB::InterpreterInsertQuery::getTable(DB::ASTInsertQuery&) @ 0x000000001492bf04 8. /build/src/Interpreters/InterpreterInsertQuery.cpp:829: DB::InterpreterInsertQuery::execute() @ 0x0000000014933938 9. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88dc9 10. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 11. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 12. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 13. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 14. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 16. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 17. ? @ 0x00007fbc6213eac3 18. ? @ 0x00007fbc621d0850 2025.07.28 11:58:53.009775 [ 17371 ] {ff8596d3-4e7a-484e-b825-7eb33adae6c6} executeQuery: Code: 60. DB::Exception: Table test_15.concurrent_optimize_table does not exist. (UNKNOWN_TABLE) (version 25.3.6.10636.altinitytest (altinity build)) (from [::1]:40120) (comment: 01103_optimize_drop_race_zookeeper.sh) (query 1, line 1) (in query: INSERT INTO concurrent_optimize_table SELECT rand(1), rand(2), 1 / rand(3), toString(rand(4)), [rand(5), rand(6)], rand(7) % 2 ? NULL : generateUUIDv4(), (rand(8), rand(9)) FROM numbers(10000)), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000a06a8eb 4. /build/src/Databases/IDatabase.cpp:41: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x0000000013dd565f 5. /build/src/Interpreters/DatabaseCatalog.cpp:442: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x00000000144f0869 6. /build/src/Interpreters/DatabaseCatalog.cpp:976: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x00000000144f6c88 7. /build/src/Interpreters/InterpreterInsertQuery.cpp:169: DB::InterpreterInsertQuery::getTable(DB::ASTInsertQuery&) @ 0x000000001492bf04 8. /build/src/Interpreters/InterpreterInsertQuery.cpp:829: DB::InterpreterInsertQuery::execute() @ 0x0000000014933938 9. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88dc9 10. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 11. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 12. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 13. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 14. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 16. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 17. ? @ 0x00007fbc6213eac3 18. ? @ 0x00007fbc621d0850 2025.07.28 11:58:53.011526 [ 17191 ] {c85cb748-c07f-4011-aac6-9b1fd4d04a3e} 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]:40098). (NETWORK_ERROR), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::NetException::NetException(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&) @ 0x000000000fd50fb5 3. /build/src/IO/WriteBufferFromPocoSocket.cpp:171: DB::WriteBufferFromPocoSocket::nextImpl() @ 0x000000000fd525a7 4. /build/src/IO/WriteBuffer.h:53: DB::WriteBuffer::next() @ 0x000000000a0755be 5. /build/src/Server/TCPHandler.cpp:826: DB::TCPHandler::runImpl() @ 0x00000000168e6c9c 6. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 7. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 8. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 9. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 10. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 11. ? @ 0x00007fbc6213eac3 12. ? @ 0x00007fbc621d0850 (version 25.3.6.10636.altinitytest (altinity build)) 2025.07.28 11:58:53.012647 [ 17232 ] {454c43b8-9e8b-4d37-99eb-99d0fb6fbe06} 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]:40114). (NETWORK_ERROR), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::NetException::NetException(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&) @ 0x000000000fd50fb5 3. /build/src/IO/WriteBufferFromPocoSocket.cpp:171: DB::WriteBufferFromPocoSocket::nextImpl() @ 0x000000000fd525a7 4. /build/src/IO/WriteBuffer.h:53: DB::WriteBuffer::next() @ 0x000000000a0755be 5. /build/src/Server/TCPHandler.cpp:826: DB::TCPHandler::runImpl() @ 0x00000000168e6c9c 6. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 7. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 8. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 9. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 10. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 11. ? @ 0x00007fbc6213eac3 12. ? @ 0x00007fbc621d0850 (version 25.3.6.10636.altinitytest (altinity build)) 2025.07.28 11:58:53.012830 [ 17191 ] {} TCPHandler: Code: 60. DB::Exception: Table test_15.concurrent_optimize_table does not exist. (UNKNOWN_TABLE), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000a06a8eb 4. /build/src/Databases/IDatabase.cpp:41: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x0000000013dd565f 5. /build/src/Interpreters/DatabaseCatalog.cpp:442: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x00000000144f0869 6. /build/src/Interpreters/DatabaseCatalog.cpp:976: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x00000000144f6c88 7. /build/src/Interpreters/InterpreterInsertQuery.cpp:169: DB::InterpreterInsertQuery::getTable(DB::ASTInsertQuery&) @ 0x000000001492bf04 8. /build/src/Interpreters/InterpreterInsertQuery.cpp:829: DB::InterpreterInsertQuery::execute() @ 0x0000000014933938 9. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88dc9 10. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 11. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 12. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 13. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 14. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 16. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 17. ? @ 0x00007fbc6213eac3 18. ? @ 0x00007fbc621d0850 2025.07.28 11:58:53.014050 [ 17371 ] {ff8596d3-4e7a-484e-b825-7eb33adae6c6} 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]:40120). (NETWORK_ERROR), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::NetException::NetException(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&) @ 0x000000000fd50fb5 3. /build/src/IO/WriteBufferFromPocoSocket.cpp:171: DB::WriteBufferFromPocoSocket::nextImpl() @ 0x000000000fd525a7 4. /build/src/IO/WriteBuffer.h:53: DB::WriteBuffer::next() @ 0x000000000a0755be 5. /build/src/Server/TCPHandler.cpp:826: DB::TCPHandler::runImpl() @ 0x00000000168e6c9c 6. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 7. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 8. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 9. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 10. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 11. ? @ 0x00007fbc6213eac3 12. ? @ 0x00007fbc621d0850 (version 25.3.6.10636.altinitytest (altinity build)) 2025.07.28 11:58:53.014277 [ 17232 ] {} TCPHandler: Code: 60. DB::Exception: Table test_15.concurrent_optimize_table does not exist. (UNKNOWN_TABLE), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000a06a8eb 4. /build/src/Databases/IDatabase.cpp:41: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x0000000013dd565f 5. /build/src/Interpreters/DatabaseCatalog.cpp:442: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x00000000144f0869 6. /build/src/Interpreters/DatabaseCatalog.cpp:976: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x00000000144f6c88 7. /build/src/Interpreters/InterpreterInsertQuery.cpp:169: DB::InterpreterInsertQuery::getTable(DB::ASTInsertQuery&) @ 0x000000001492bf04 8. /build/src/Interpreters/InterpreterInsertQuery.cpp:829: DB::InterpreterInsertQuery::execute() @ 0x0000000014933938 9. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88dc9 10. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 11. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 12. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 13. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 14. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 16. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 17. ? @ 0x00007fbc6213eac3 18. ? @ 0x00007fbc621d0850 2025.07.28 11:58:53.017503 [ 17371 ] {} TCPHandler: Code: 60. DB::Exception: Table test_15.concurrent_optimize_table does not exist. (UNKNOWN_TABLE), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000a06a8eb 4. /build/src/Databases/IDatabase.cpp:41: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x0000000013dd565f 5. /build/src/Interpreters/DatabaseCatalog.cpp:442: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x00000000144f0869 6. /build/src/Interpreters/DatabaseCatalog.cpp:976: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x00000000144f6c88 7. /build/src/Interpreters/InterpreterInsertQuery.cpp:169: DB::InterpreterInsertQuery::getTable(DB::ASTInsertQuery&) @ 0x000000001492bf04 8. /build/src/Interpreters/InterpreterInsertQuery.cpp:829: DB::InterpreterInsertQuery::execute() @ 0x0000000014933938 9. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88dc9 10. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 11. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 12. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 13. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 14. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 16. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 17. ? @ 0x00007fbc6213eac3 18. ? @ 0x00007fbc621d0850 2025.07.28 11:58:53.170479 [ 17252 ] {858944c0-3ef2-4335-a9ac-7e5c0a850255} executeQuery: Code: 415. DB::Exception: Cannot create a replica of the table /clickhouse/tables/01103_optimize_drop_race_zookeeper_test_15/concurrent_optimize_table, because the last replica of the table was dropped right now. (ALL_REPLICAS_LOST) (version 25.3.6.10636.altinitytest (altinity build)) (from [::1]:40042) (comment: 01103_optimize_drop_race_zookeeper.sh) (query 2, line 2) (in query: CREATE TABLE concurrent_optimize_table (`a` UInt8, `b` Int16, `c` Float32, `d` String, `e` Array(UInt8), `f` Nullable(UUID), `g` Tuple(UInt8, UInt16)) ENGINE = ReplicatedMergeTree('/clickhouse/tables/01103_optimize_drop_race_zookeeper_test_15/concurrent_optimize_table', '1') PARTITION BY b % 10 ORDER BY a SETTINGS old_parts_lifetime = 1, cleanup_delay_period = 0, cleanup_delay_period_random_add = 0, cleanup_thread_preferred_points_per_iteration = 0, index_granularity = 31489, 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 = 20868213, compact_parts_max_bytes_to_buffer = 108362629, compact_parts_max_granules_to_buffer = 1, compact_parts_merge_max_bytes_to_prefetch_part = 18898448, merge_max_block_size = 13220, prefer_fetch_merged_part_size_threshold = 1, vertical_merge_algorithm_min_rows_to_activate = 1000000, vertical_merge_algorithm_min_columns_to_activate = 76, min_merge_bytes_to_use_direct_io = 10737418240, index_granularity_bytes = 7046892, use_const_adaptive_granularity = false, 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 = true, cache_populated_by_fetch = false, marks_compress_block_size = 84392, primary_key_compress_block_size = 23861, 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. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000a9b78ab 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:1187: DB::StorageReplicatedMergeTree::createReplicaAttempt(std::shared_ptr const&, std::shared_ptr) const @ 0x0000000015ea1127 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:1087: DB::StorageReplicatedMergeTree::createReplica(std::shared_ptr const&, DB::ZooKeeperRetriesInfo const&) const @ 0x0000000015e8c7b5 6. /build/src/Storages/StorageReplicatedMergeTree.cpp:624: DB::StorageReplicatedMergeTree::StorageReplicatedMergeTree(DB::TableZnodeInfo const&, DB::LoadingStrictnessLevel, DB::StorageID const&, String const&, DB::StorageInMemoryMetadata const&, std::shared_ptr, String const&, DB::MergeTreeData::MergingParams const&, std::unique_ptr>, bool, DB::ZooKeeperRetriesInfo const&) @ 0x0000000015e8979f 7. /build/contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: std::shared_ptr std::allocate_shared[abi:se190107], DB::TableZnodeInfo&, DB::LoadingStrictnessLevel const&, DB::StorageID const&, String const&, DB::StorageInMemoryMetadata&, std::shared_ptr&, String&, DB::MergeTreeData::MergingParams&, std::unique_ptr>, bool&, DB::ZooKeeperRetriesInfo&, 0>(std::allocator const&, DB::TableZnodeInfo&, DB::LoadingStrictnessLevel const&, DB::StorageID const&, String const&, DB::StorageInMemoryMetadata&, std::shared_ptr&, String&, DB::MergeTreeData::MergingParams&, std::unique_ptr>&&, bool&, DB::ZooKeeperRetriesInfo&) @ 0x000000001663250b 8. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:851: DB::create(DB::StorageFactory::Arguments const&) @ 0x000000001662ef92 9. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000015d81ea2 10. /build/src/Interpreters/InterpreterCreateQuery.cpp:1945: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x00000000149009bb 11. /build/src/Interpreters/InterpreterCreateQuery.cpp:1743: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000148f9aa9 12. /build/src/Interpreters/InterpreterCreateQuery.cpp:2352: DB::InterpreterCreateQuery::execute() @ 0x0000000014905a41 13. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88dc9 14. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 15. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 16. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 17. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 18. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 19. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 20. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 21. ? @ 0x00007fbc6213eac3 22. ? @ 0x00007fbc621d0850 2025.07.28 11:58:53.190800 [ 17252 ] {858944c0-3ef2-4335-a9ac-7e5c0a850255} 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]:40042). (NETWORK_ERROR), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::NetException::NetException(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&) @ 0x000000000fd50fb5 3. /build/src/IO/WriteBufferFromPocoSocket.cpp:171: DB::WriteBufferFromPocoSocket::nextImpl() @ 0x000000000fd525a7 4. /build/src/IO/WriteBuffer.h:53: DB::WriteBuffer::next() @ 0x000000000a0755be 5. /build/src/Server/TCPHandler.cpp:826: DB::TCPHandler::runImpl() @ 0x00000000168e6c9c 6. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 7. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 8. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 9. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 10. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 11. ? @ 0x00007fbc6213eac3 12. ? @ 0x00007fbc621d0850 (version 25.3.6.10636.altinitytest (altinity build)) 2025.07.28 11:58:53.196177 [ 17252 ] {} TCPHandler: Code: 415. DB::Exception: Cannot create a replica of the table /clickhouse/tables/01103_optimize_drop_race_zookeeper_test_15/concurrent_optimize_table, because the last replica of the table was dropped right now. (ALL_REPLICAS_LOST), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000a9b78ab 4. /build/src/Storages/StorageReplicatedMergeTree.cpp:1187: DB::StorageReplicatedMergeTree::createReplicaAttempt(std::shared_ptr const&, std::shared_ptr) const @ 0x0000000015ea1127 5. /build/src/Storages/StorageReplicatedMergeTree.cpp:1087: DB::StorageReplicatedMergeTree::createReplica(std::shared_ptr const&, DB::ZooKeeperRetriesInfo const&) const @ 0x0000000015e8c7b5 6. /build/src/Storages/StorageReplicatedMergeTree.cpp:624: DB::StorageReplicatedMergeTree::StorageReplicatedMergeTree(DB::TableZnodeInfo const&, DB::LoadingStrictnessLevel, DB::StorageID const&, String const&, DB::StorageInMemoryMetadata const&, std::shared_ptr, String const&, DB::MergeTreeData::MergingParams const&, std::unique_ptr>, bool, DB::ZooKeeperRetriesInfo const&) @ 0x0000000015e8979f 7. /build/contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: std::shared_ptr std::allocate_shared[abi:se190107], DB::TableZnodeInfo&, DB::LoadingStrictnessLevel const&, DB::StorageID const&, String const&, DB::StorageInMemoryMetadata&, std::shared_ptr&, String&, DB::MergeTreeData::MergingParams&, std::unique_ptr>, bool&, DB::ZooKeeperRetriesInfo&, 0>(std::allocator const&, DB::TableZnodeInfo&, DB::LoadingStrictnessLevel const&, DB::StorageID const&, String const&, DB::StorageInMemoryMetadata&, std::shared_ptr&, String&, DB::MergeTreeData::MergingParams&, std::unique_ptr>&&, bool&, DB::ZooKeeperRetriesInfo&) @ 0x000000001663250b 8. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:851: DB::create(DB::StorageFactory::Arguments const&) @ 0x000000001662ef92 9. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000015d81ea2 10. /build/src/Interpreters/InterpreterCreateQuery.cpp:1945: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x00000000149009bb 11. /build/src/Interpreters/InterpreterCreateQuery.cpp:1743: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000148f9aa9 12. /build/src/Interpreters/InterpreterCreateQuery.cpp:2352: DB::InterpreterCreateQuery::execute() @ 0x0000000014905a41 13. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88dc9 14. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 15. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 16. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 17. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 18. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 19. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 20. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 21. ? @ 0x00007fbc6213eac3 22. ? @ 0x00007fbc621d0850 2025.07.28 11:58:53.366620 [ 4446 ] {} 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. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception>&, String>(int, FormatStringHelperImpl>&>::type, std::type_identity::type>, std::basic_string_view>&, String&&) @ 0x000000001385a5eb 4. /build/src/Access/SettingsConstraints.cpp:376: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000013859b18 5. /build/src/Access/SettingsConstraints.cpp:300: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000013858faf 6. /build/src/Access/SettingsConstraints.cpp:209: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000013859223 7. /build/src/Interpreters/Context.cpp:2690: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000014436134 8. /build/src/Interpreters/Context.cpp:2729: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x000000001443662b 9. /build/src/Server/HTTPHandler.cpp:457: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000001686d165 10. /build/src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x0000000016870807 11. /build/src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x0000000016907e99 12. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 13. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 14. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 15. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 16. ? @ 0x00007fbc6213eac3 17. ? @ 0x00007fbc621d0850 (version 25.3.6.10636.altinitytest (altinity build)) 2025.07.28 11:58:53.366635 [ 3970 ] {} test_13.rmt2 (7f9b740d-015c-470e-8cc6-8ba33be0dc63): auto DB::StorageReplicatedMergeTree::processQueueEntry(ReplicatedMergeTreeQueue::SelectedEntryPtr)::(anonymous class)::operator()(LogEntryPtr &) const: Code: 86. DB::HTTPException: Received error from remote server http://146b4357c08d:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Ftest%2F01165%2Ftest_13%2Frmt%2Freplicas%2F1&part=20250728_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.6.10636.altinitytest (altinity build)) '. (RECEIVED_ERROR_FROM_REMOTE_IO_SERVER), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.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 const&, int&&, String const&, unsigned long&&, String const&) @ 0x000000000feda8d9 4. /build/src/IO/HTTPCommon.cpp:104: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x000000000feda6e2 5. /build/src/IO/HTTPCommon.cpp:93: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x000000000feda537 6. /build/src/IO/ReadWriteBufferFromHTTP.cpp:277: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x000000001184a4c4 7. /build/src/IO/ReadWriteBufferFromHTTP.cpp:285: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x000000001184a615 8. /build/src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x000000001184ae59 9. /build/src/IO/ReadWriteBufferFromHTTP.cpp:472: void std::__function::__policy_invoker::__call_impl[abi:se190107]>(std::__function::__policy_storage const*) @ 0x000000001184cedd 10. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001184858b 11. /build/src/IO/ReadWriteBufferFromHTTP.cpp:465: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x000000001184bf0b 12. /build/src/IO/ReadBuffer.h:60: DB::ReadBuffer::next() @ 0x000000000a148c7b 13. /build/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) @ 0x0000000011849fb2 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]>&)>&, 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&) @ 0x0000000011841980 15. /build/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) @ 0x000000001621208e 16. /build/src/Storages/StorageReplicatedMergeTree.cpp:5228: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl[abi:se190107] const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000015f9a5fe 17. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000015ed8bfd 18. /build/src/Storages/StorageReplicatedMergeTree.cpp:2514: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x0000000015ec9aab 19. /build/src/Storages/StorageReplicatedMergeTree.cpp:2349: DB::StorageReplicatedMergeTree::executeLogEntry(DB::ReplicatedMergeTreeLogEntry&) @ 0x0000000015eba91b 20. /build/src/Storages/StorageReplicatedMergeTree.cpp:3876: bool std::__function::__policy_invoker&)>::__call_impl[abi:se190107])::$_1, bool (std::shared_ptr&)>>(std::__function::__policy_storage const*, std::shared_ptr&) @ 0x0000000015f9837e 21. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000165d6fc3 22. /build/src/Storages/StorageReplicatedMergeTree.cpp:3872: DB::StorageReplicatedMergeTree::processQueueEntry(std::shared_ptr) @ 0x0000000015efc18a 23. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001624c1b2 24. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000162f9c70 25. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x00000000162fa55a 26. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc6653 27. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000000fccc4c3 28. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc3d92 29. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fcca080 30. ? @ 0x00007fbc6213eac3 31. ? @ 0x00007fbc621d0850 (version 25.3.6.10636.altinitytest (altinity build)) 2025.07.28 11:58:53.498395 [ 3285 ] {} 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. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception>&, String>(int, FormatStringHelperImpl>&>::type, std::type_identity::type>, std::basic_string_view>&, String&&) @ 0x000000001385a5eb 4. /build/src/Access/SettingsConstraints.cpp:376: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000013859b18 5. /build/src/Access/SettingsConstraints.cpp:300: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000013858faf 6. /build/src/Access/SettingsConstraints.cpp:209: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000013859223 7. /build/src/Interpreters/Context.cpp:2690: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000014436134 8. /build/src/Interpreters/Context.cpp:2729: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x000000001443662b 9. /build/src/Server/HTTPHandler.cpp:457: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000001686d165 10. /build/src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x0000000016870807 11. /build/src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x0000000016907e99 12. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 13. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 14. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 15. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 16. ? @ 0x00007fbc6213eac3 17. ? @ 0x00007fbc621d0850 (version 25.3.6.10636.altinitytest (altinity build)) 2025.07.28 11:58:54.334851 [ 3961 ] {} test_13.rmt2 (7f9b740d-015c-470e-8cc6-8ba33be0dc63): auto DB::StorageReplicatedMergeTree::processQueueEntry(ReplicatedMergeTreeQueue::SelectedEntryPtr)::(anonymous class)::operator()(LogEntryPtr &) const: Code: 86. DB::HTTPException: Received error from remote server http://146b4357c08d:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Ftest%2F01165%2Ftest_13%2Frmt%2Freplicas%2F1&part=20250728_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.6.10636.altinitytest (altinity build)) '. (RECEIVED_ERROR_FROM_REMOTE_IO_SERVER), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.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 const&, int&&, String const&, unsigned long&&, String const&) @ 0x000000000feda8d9 4. /build/src/IO/HTTPCommon.cpp:104: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x000000000feda6e2 5. /build/src/IO/HTTPCommon.cpp:93: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x000000000feda537 6. /build/src/IO/ReadWriteBufferFromHTTP.cpp:277: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x000000001184a4c4 7. /build/src/IO/ReadWriteBufferFromHTTP.cpp:285: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x000000001184a615 8. /build/src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x000000001184ae59 9. /build/src/IO/ReadWriteBufferFromHTTP.cpp:472: void std::__function::__policy_invoker::__call_impl[abi:se190107]>(std::__function::__policy_storage const*) @ 0x000000001184cedd 10. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001184858b 11. /build/src/IO/ReadWriteBufferFromHTTP.cpp:465: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x000000001184bf0b 12. /build/src/IO/ReadBuffer.h:60: DB::ReadBuffer::next() @ 0x000000000a148c7b 13. /build/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) @ 0x0000000011849fb2 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]>&)>&, 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&) @ 0x0000000011841980 15. /build/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) @ 0x000000001621208e 16. /build/src/Storages/StorageReplicatedMergeTree.cpp:5228: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl[abi:se190107] const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000015f9a5fe 17. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000015ed8bfd 18. /build/src/Storages/StorageReplicatedMergeTree.cpp:2514: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x0000000015ec9aab 19. /build/src/Storages/StorageReplicatedMergeTree.cpp:2349: DB::StorageReplicatedMergeTree::executeLogEntry(DB::ReplicatedMergeTreeLogEntry&) @ 0x0000000015eba91b 20. /build/src/Storages/StorageReplicatedMergeTree.cpp:3876: bool std::__function::__policy_invoker&)>::__call_impl[abi:se190107])::$_1, bool (std::shared_ptr&)>>(std::__function::__policy_storage const*, std::shared_ptr&) @ 0x0000000015f9837e 21. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000165d6fc3 22. /build/src/Storages/StorageReplicatedMergeTree.cpp:3872: DB::StorageReplicatedMergeTree::processQueueEntry(std::shared_ptr) @ 0x0000000015efc18a 23. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001624c1b2 24. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000162f9c70 25. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x00000000162fa55a 26. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc6653 27. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000000fccc4c3 28. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc3d92 29. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fcca080 30. ? @ 0x00007fbc6213eac3 31. ? @ 0x00007fbc621d0850 (version 25.3.6.10636.altinitytest (altinity build)) 2025.07.28 11:58:54.920256 [ 3965 ] {} test_13.rmt2 (7f9b740d-015c-470e-8cc6-8ba33be0dc63): auto DB::StorageReplicatedMergeTree::processQueueEntry(ReplicatedMergeTreeQueue::SelectedEntryPtr)::(anonymous class)::operator()(LogEntryPtr &) const: Code: 86. DB::HTTPException: Received error from remote server http://146b4357c08d:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Ftest%2F01165%2Ftest_13%2Frmt%2Freplicas%2F1&part=20250728_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.6.10636.altinitytest (altinity build)) '. (RECEIVED_ERROR_FROM_REMOTE_IO_SERVER), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.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 const&, int&&, String const&, unsigned long&&, String const&) @ 0x000000000feda8d9 4. /build/src/IO/HTTPCommon.cpp:104: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x000000000feda6e2 5. /build/src/IO/HTTPCommon.cpp:93: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x000000000feda537 6. /build/src/IO/ReadWriteBufferFromHTTP.cpp:277: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x000000001184a4c4 7. /build/src/IO/ReadWriteBufferFromHTTP.cpp:285: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x000000001184a615 8. /build/src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x000000001184ae59 9. /build/src/IO/ReadWriteBufferFromHTTP.cpp:472: void std::__function::__policy_invoker::__call_impl[abi:se190107]>(std::__function::__policy_storage const*) @ 0x000000001184cedd 10. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001184858b 11. /build/src/IO/ReadWriteBufferFromHTTP.cpp:465: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x000000001184bf0b 12. /build/src/IO/ReadBuffer.h:60: DB::ReadBuffer::next() @ 0x000000000a148c7b 13. /build/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) @ 0x0000000011849fb2 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]>&)>&, 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&) @ 0x0000000011841980 15. /build/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) @ 0x000000001621208e 16. /build/src/Storages/StorageReplicatedMergeTree.cpp:5228: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl[abi:se190107] const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000015f9a5fe 17. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000015ed8bfd 18. /build/src/Storages/StorageReplicatedMergeTree.cpp:2514: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x0000000015ec9aab 19. /build/src/Storages/StorageReplicatedMergeTree.cpp:2349: DB::StorageReplicatedMergeTree::executeLogEntry(DB::ReplicatedMergeTreeLogEntry&) @ 0x0000000015eba91b 20. /build/src/Storages/StorageReplicatedMergeTree.cpp:3876: bool std::__function::__policy_invoker&)>::__call_impl[abi:se190107])::$_1, bool (std::shared_ptr&)>>(std::__function::__policy_storage const*, std::shared_ptr&) @ 0x0000000015f9837e 21. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000165d6fc3 22. /build/src/Storages/StorageReplicatedMergeTree.cpp:3872: DB::StorageReplicatedMergeTree::processQueueEntry(std::shared_ptr) @ 0x0000000015efc18a 23. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001624c1b2 24. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000162f9c70 25. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x00000000162fa55a 26. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc6653 27. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000000fccc4c3 28. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc3d92 29. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fcca080 30. ? @ 0x00007fbc6213eac3 31. ? @ 0x00007fbc621d0850 (version 25.3.6.10636.altinitytest (altinity build)) 2025.07.28 11:58:55.105282 [ 4963 ] {13e4c042-182f-45e0-8e86-18eaa9fbc8cb} executeQuery: Code: 344. DB::Exception: FINAL modifier is not supported with parallel replicas. (SUPPORT_IS_DISABLED) (version 25.3.6.10636.altinitytest (altinity build)) (from [::1]:40162) (comment: 03222_parallel_replicas_final_in_subquery.sql) (query 7, line 20) (in query: SELECT * FROM (SELECT * FROM test_00808 FINAL) WHERE id = 1;), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000000a074fcb 4. /build/src/Planner/Planner.cpp:1517: DB::Planner::buildPlanForQueryNode() @ 0x000000001497f5e4 5. /build/src/Planner/Planner.cpp:1308: DB::Planner::buildQueryPlanIfNeeded() @ 0x000000001497685c 6. /build/src/Planner/PlannerJoinTree.cpp:1202: DB::(anonymous namespace)::buildQueryPlanForTableExpression(std::shared_ptr, std::shared_ptr const&, DB::SelectQueryInfo const&, DB::SelectQueryOptions const&, std::shared_ptr&, bool, bool) @ 0x0000000014994644 7. /build/src/Planner/PlannerJoinTree.cpp:2252: DB::buildJoinTreeQueryPlan(std::shared_ptr const&, DB::SelectQueryInfo const&, DB::SelectQueryOptions&, std::unordered_set, std::equal_to, std::allocator> const&, std::shared_ptr&) @ 0x000000001498e109 8. /build/src/Planner/Planner.cpp:1553: DB::Planner::buildPlanForQueryNode() @ 0x0000000014979dae 9. /build/src/Planner/Planner.cpp:1308: DB::Planner::buildQueryPlanIfNeeded() @ 0x000000001497685c 10. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:255: DB::InterpreterSelectQueryAnalyzer::getQueryPlan() @ 0x000000001497476d 11. /build/src/Interpreters/executeQuery.cpp:1405: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88806 12. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 13. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 14. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 15. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 16. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 17. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 18. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 19. ? @ 0x00007fbc6213eac3 20. ? @ 0x00007fbc621d0850 2025.07.28 11:58:55.112078 [ 4963 ] {} TCPHandler: Code: 344. DB::Exception: FINAL modifier is not supported with parallel replicas. (SUPPORT_IS_DISABLED), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000000a074fcb 4. /build/src/Planner/Planner.cpp:1517: DB::Planner::buildPlanForQueryNode() @ 0x000000001497f5e4 5. /build/src/Planner/Planner.cpp:1308: DB::Planner::buildQueryPlanIfNeeded() @ 0x000000001497685c 6. /build/src/Planner/PlannerJoinTree.cpp:1202: DB::(anonymous namespace)::buildQueryPlanForTableExpression(std::shared_ptr, std::shared_ptr const&, DB::SelectQueryInfo const&, DB::SelectQueryOptions const&, std::shared_ptr&, bool, bool) @ 0x0000000014994644 7. /build/src/Planner/PlannerJoinTree.cpp:2252: DB::buildJoinTreeQueryPlan(std::shared_ptr const&, DB::SelectQueryInfo const&, DB::SelectQueryOptions&, std::unordered_set, std::equal_to, std::allocator> const&, std::shared_ptr&) @ 0x000000001498e109 8. /build/src/Planner/Planner.cpp:1553: DB::Planner::buildPlanForQueryNode() @ 0x0000000014979dae 9. /build/src/Planner/Planner.cpp:1308: DB::Planner::buildQueryPlanIfNeeded() @ 0x000000001497685c 10. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:255: DB::InterpreterSelectQueryAnalyzer::getQueryPlan() @ 0x000000001497476d 11. /build/src/Interpreters/executeQuery.cpp:1405: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88806 12. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 13. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 14. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 15. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 16. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 17. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 18. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 19. ? @ 0x00007fbc6213eac3 20. ? @ 0x00007fbc621d0850 2025.07.28 11:58:55.561674 [ 3976 ] {} test_13.rmt2 (7f9b740d-015c-470e-8cc6-8ba33be0dc63): auto DB::StorageReplicatedMergeTree::processQueueEntry(ReplicatedMergeTreeQueue::SelectedEntryPtr)::(anonymous class)::operator()(LogEntryPtr &) const: Code: 86. DB::HTTPException: Received error from remote server http://146b4357c08d:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Ftest%2F01165%2Ftest_13%2Frmt%2Freplicas%2F1&part=20250728_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.6.10636.altinitytest (altinity build)) '. (RECEIVED_ERROR_FROM_REMOTE_IO_SERVER), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.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 const&, int&&, String const&, unsigned long&&, String const&) @ 0x000000000feda8d9 4. /build/src/IO/HTTPCommon.cpp:104: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x000000000feda6e2 5. /build/src/IO/HTTPCommon.cpp:93: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x000000000feda537 6. /build/src/IO/ReadWriteBufferFromHTTP.cpp:277: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x000000001184a4c4 7. /build/src/IO/ReadWriteBufferFromHTTP.cpp:285: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x000000001184a615 8. /build/src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x000000001184ae59 9. /build/src/IO/ReadWriteBufferFromHTTP.cpp:472: void std::__function::__policy_invoker::__call_impl[abi:se190107]>(std::__function::__policy_storage const*) @ 0x000000001184cedd 10. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001184858b 11. /build/src/IO/ReadWriteBufferFromHTTP.cpp:465: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x000000001184bf0b 12. /build/src/IO/ReadBuffer.h:60: DB::ReadBuffer::next() @ 0x000000000a148c7b 13. /build/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) @ 0x0000000011849fb2 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]>&)>&, 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&) @ 0x0000000011841980 15. /build/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) @ 0x000000001621208e 16. /build/src/Storages/StorageReplicatedMergeTree.cpp:5228: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl[abi:se190107] const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000015f9a5fe 17. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000015ed8bfd 18. /build/src/Storages/StorageReplicatedMergeTree.cpp:2514: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x0000000015ec9aab 19. /build/src/Storages/StorageReplicatedMergeTree.cpp:2349: DB::StorageReplicatedMergeTree::executeLogEntry(DB::ReplicatedMergeTreeLogEntry&) @ 0x0000000015eba91b 20. /build/src/Storages/StorageReplicatedMergeTree.cpp:3876: bool std::__function::__policy_invoker&)>::__call_impl[abi:se190107])::$_1, bool (std::shared_ptr&)>>(std::__function::__policy_storage const*, std::shared_ptr&) @ 0x0000000015f9837e 21. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000165d6fc3 22. /build/src/Storages/StorageReplicatedMergeTree.cpp:3872: DB::StorageReplicatedMergeTree::processQueueEntry(std::shared_ptr) @ 0x0000000015efc18a 23. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001624c1b2 24. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000162f9c70 25. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x00000000162fa55a 26. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc6653 27. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000000fccc4c3 28. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc3d92 29. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fcca080 30. ? @ 0x00007fbc6213eac3 31. ? @ 0x00007fbc621d0850 (version 25.3.6.10636.altinitytest (altinity build)) 2025.07.28 11:58:55.868842 [ 3961 ] {} test_13.rmt2 (7f9b740d-015c-470e-8cc6-8ba33be0dc63): auto DB::StorageReplicatedMergeTree::processQueueEntry(ReplicatedMergeTreeQueue::SelectedEntryPtr)::(anonymous class)::operator()(LogEntryPtr &) const: Code: 86. DB::HTTPException: Received error from remote server http://146b4357c08d:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Ftest%2F01165%2Ftest_13%2Frmt%2Freplicas%2F1&part=20250728_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.6.10636.altinitytest (altinity build)) '. (RECEIVED_ERROR_FROM_REMOTE_IO_SERVER), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.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 const&, int&&, String const&, unsigned long&&, String const&) @ 0x000000000feda8d9 4. /build/src/IO/HTTPCommon.cpp:104: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x000000000feda6e2 5. /build/src/IO/HTTPCommon.cpp:93: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x000000000feda537 6. /build/src/IO/ReadWriteBufferFromHTTP.cpp:277: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x000000001184a4c4 7. /build/src/IO/ReadWriteBufferFromHTTP.cpp:285: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x000000001184a615 8. /build/src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x000000001184ae59 9. /build/src/IO/ReadWriteBufferFromHTTP.cpp:472: void std::__function::__policy_invoker::__call_impl[abi:se190107]>(std::__function::__policy_storage const*) @ 0x000000001184cedd 10. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001184858b 11. /build/src/IO/ReadWriteBufferFromHTTP.cpp:465: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x000000001184bf0b 12. /build/src/IO/ReadBuffer.h:60: DB::ReadBuffer::next() @ 0x000000000a148c7b 13. /build/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) @ 0x0000000011849fb2 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]>&)>&, 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&) @ 0x0000000011841980 15. /build/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) @ 0x000000001621208e 16. /build/src/Storages/StorageReplicatedMergeTree.cpp:5228: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl[abi:se190107] const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000015f9a5fe 17. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000015ed8bfd 18. /build/src/Storages/StorageReplicatedMergeTree.cpp:2514: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x0000000015ec9aab 19. /build/src/Storages/StorageReplicatedMergeTree.cpp:2349: DB::StorageReplicatedMergeTree::executeLogEntry(DB::ReplicatedMergeTreeLogEntry&) @ 0x0000000015eba91b 20. /build/src/Storages/StorageReplicatedMergeTree.cpp:3876: bool std::__function::__policy_invoker&)>::__call_impl[abi:se190107])::$_1, bool (std::shared_ptr&)>>(std::__function::__policy_storage const*, std::shared_ptr&) @ 0x0000000015f9837e 21. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000165d6fc3 22. /build/src/Storages/StorageReplicatedMergeTree.cpp:3872: DB::StorageReplicatedMergeTree::processQueueEntry(std::shared_ptr) @ 0x0000000015efc18a 23. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001624c1b2 24. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000162f9c70 25. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x00000000162fa55a 26. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc6653 27. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000000fccc4c3 28. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc3d92 29. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fcca080 30. ? @ 0x00007fbc6213eac3 31. ? @ 0x00007fbc621d0850 (version 25.3.6.10636.altinitytest (altinity build)) 2025.07.28 11:58:56.109154 [ 11851 ] {ad0bbfdc-e74e-468e-81da-48bb60c396b0} executeQuery: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=1, jobs=1). (CANNOT_SCHEDULE_TASK) (version 25.3.6.10636.altinitytest (altinity build)) (from [::1]:54456) (comment: 01395_limit_more_cases_random.sh) (query 234, line 1632) (in query: WITH count() AS c, min(number) AS first, max(number) AS last SELECT throwIf(first != (7 < 2 AND 33 > 0 ? 7 : 0)), throwIf(last != (7 < 2 AND 33 > 0 ? least(2 - 1, 7 + 33 - 1) : 0)), throwIf((c != 0 OR first != 0 OR last != 0) AND (c != last - first + 1)) FROM (SELECT * FROM numbers(2) LIMIT 7, 33);), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000fccaeeb 4. /build/src/Common/ThreadPool.cpp:275: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000fccc813 5. /build/src/Common/ThreadPool.cpp:323: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fcc7bbc 6. /build/src/Common/ThreadPool.cpp:494: ThreadPoolImpl>::scheduleOrThrowOnError(std::function, Priority) @ 0x000000000fcc7a0e 7. /build/src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::spawnThreadsImpl() @ 0x00000000169b2c0c 8. /build/src/Processors/Executors/PipelineExecutor.cpp:394: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x00000000169b0ba7 9. /build/src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x00000000169b03f4 10. /build/src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:se190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169bfeab 11. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc3d92 12. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fcca080 13. ? @ 0x00007fbc6213eac3 14. ? @ 0x00007fbc621d0850 2025.07.28 11:58:56.124351 [ 11851 ] {} 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. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000fccaeeb 4. /build/src/Common/ThreadPool.cpp:275: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000fccc813 5. /build/src/Common/ThreadPool.cpp:323: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fcc7bbc 6. /build/src/Common/ThreadPool.cpp:494: ThreadPoolImpl>::scheduleOrThrowOnError(std::function, Priority) @ 0x000000000fcc7a0e 7. /build/src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::spawnThreadsImpl() @ 0x00000000169b2c0c 8. /build/src/Processors/Executors/PipelineExecutor.cpp:394: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x00000000169b0ba7 9. /build/src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x00000000169b03f4 10. /build/src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:se190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169bfeab 11. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc3d92 12. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fcca080 13. ? @ 0x00007fbc6213eac3 14. ? @ 0x00007fbc621d0850 Job's origin stack trace: 0. /build/src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000000fc33b84 1. /build/src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000000fcc2ea7 2. /build/src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fcc535c 3. /build/src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000000fcc584d 4. /build/src/Common/ThreadPool.h:279: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x00000000169bf193 5. /build/src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x00000000169bf518 6. /build/src/Server/TCPHandler.cpp:1237: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x00000000168f1525 7. /build/src/Server/TCPHandler.cpp:678: DB::TCPHandler::runImpl() @ 0x00000000168e68e5 8. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 9. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 10. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 11. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 12. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 13. ? @ 0x00007fbc6213eac3 14. ? @ 0x00007fbc621d0850 2025.07.28 11:58:56.170392 [ 5879 ] {c663e880-dfd5-40ab-b94b-4878684d0046} executeQuery: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=1, jobs=1). (CANNOT_SCHEDULE_TASK) (version 25.3.6.10636.altinitytest (altinity build)) (from [::1]:40214) (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. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000fccaeeb 4. /build/src/Common/ThreadPool.cpp:275: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000fccc813 5. /build/src/Common/ThreadPool.cpp:323: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fcc7bbc 6. /build/src/Common/ThreadPool.cpp:494: ThreadPoolImpl>::scheduleOrThrowOnError(std::function, Priority) @ 0x000000000fcc7a0e 7. /build/src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::spawnThreadsImpl() @ 0x00000000169b2c0c 8. /build/src/Processors/Executors/PipelineExecutor.cpp:394: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x00000000169b0ba7 9. /build/src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x00000000169b03f4 10. /build/src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:se190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169bfeab 11. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc3d92 12. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fcca080 13. ? @ 0x00007fbc6213eac3 14. ? @ 0x00007fbc621d0850 2025.07.28 11:58:56.201821 [ 5879 ] {} 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. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000fccaeeb 4. /build/src/Common/ThreadPool.cpp:275: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000fccc813 5. /build/src/Common/ThreadPool.cpp:323: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fcc7bbc 6. /build/src/Common/ThreadPool.cpp:494: ThreadPoolImpl>::scheduleOrThrowOnError(std::function, Priority) @ 0x000000000fcc7a0e 7. /build/src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::spawnThreadsImpl() @ 0x00000000169b2c0c 8. /build/src/Processors/Executors/PipelineExecutor.cpp:394: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x00000000169b0ba7 9. /build/src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x00000000169b03f4 10. /build/src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:se190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169bfeab 11. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc3d92 12. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fcca080 13. ? @ 0x00007fbc6213eac3 14. ? @ 0x00007fbc621d0850 Job's origin stack trace: 0. /build/src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000000fc33b84 1. /build/src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000000fcc2ea7 2. /build/src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fcc535c 3. /build/src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000000fcc584d 4. /build/src/Common/ThreadPool.h:279: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x00000000169bf193 5. /build/src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x00000000169bf518 6. /build/src/Server/TCPHandler.cpp:1237: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x00000000168f1525 7. /build/src/Server/TCPHandler.cpp:678: DB::TCPHandler::runImpl() @ 0x00000000168e68e5 8. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 9. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 10. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 11. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 12. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 13. ? @ 0x00007fbc6213eac3 14. ? @ 0x00007fbc621d0850 2025.07.28 11:58:56.768959 [ 3964 ] {} test_13.rmt2 (7f9b740d-015c-470e-8cc6-8ba33be0dc63): auto DB::StorageReplicatedMergeTree::processQueueEntry(ReplicatedMergeTreeQueue::SelectedEntryPtr)::(anonymous class)::operator()(LogEntryPtr &) const: Code: 86. DB::HTTPException: Received error from remote server http://146b4357c08d:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Ftest%2F01165%2Ftest_13%2Frmt%2Freplicas%2F1&part=20250728_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.6.10636.altinitytest (altinity build)) '. (RECEIVED_ERROR_FROM_REMOTE_IO_SERVER), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.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 const&, int&&, String const&, unsigned long&&, String const&) @ 0x000000000feda8d9 4. /build/src/IO/HTTPCommon.cpp:104: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x000000000feda6e2 5. /build/src/IO/HTTPCommon.cpp:93: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x000000000feda537 6. /build/src/IO/ReadWriteBufferFromHTTP.cpp:277: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x000000001184a4c4 7. /build/src/IO/ReadWriteBufferFromHTTP.cpp:285: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x000000001184a615 8. /build/src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x000000001184ae59 9. /build/src/IO/ReadWriteBufferFromHTTP.cpp:472: void std::__function::__policy_invoker::__call_impl[abi:se190107]>(std::__function::__policy_storage const*) @ 0x000000001184cedd 10. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001184858b 11. /build/src/IO/ReadWriteBufferFromHTTP.cpp:465: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x000000001184bf0b 12. /build/src/IO/ReadBuffer.h:60: DB::ReadBuffer::next() @ 0x000000000a148c7b 13. /build/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) @ 0x0000000011849fb2 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]>&)>&, 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&) @ 0x0000000011841980 15. /build/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) @ 0x000000001621208e 16. /build/src/Storages/StorageReplicatedMergeTree.cpp:5228: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl[abi:se190107] const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000015f9a5fe 17. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000015ed8bfd 18. /build/src/Storages/StorageReplicatedMergeTree.cpp:2514: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x0000000015ec9aab 19. /build/src/Storages/StorageReplicatedMergeTree.cpp:2349: DB::StorageReplicatedMergeTree::executeLogEntry(DB::ReplicatedMergeTreeLogEntry&) @ 0x0000000015eba91b 20. /build/src/Storages/StorageReplicatedMergeTree.cpp:3876: bool std::__function::__policy_invoker&)>::__call_impl[abi:se190107])::$_1, bool (std::shared_ptr&)>>(std::__function::__policy_storage const*, std::shared_ptr&) @ 0x0000000015f9837e 21. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000165d6fc3 22. /build/src/Storages/StorageReplicatedMergeTree.cpp:3872: DB::StorageReplicatedMergeTree::processQueueEntry(std::shared_ptr) @ 0x0000000015efc18a 23. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001624c1b2 24. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000162f9c70 25. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x00000000162fa55a 26. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc6653 27. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000000fccc4c3 28. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc3d92 29. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fcca080 30. ? @ 0x00007fbc6213eac3 31. ? @ 0x00007fbc621d0850 (version 25.3.6.10636.altinitytest (altinity build)) 2025.07.28 11:58:57.223787 [ 17371 ] {f44debdb-e0a5-4776-a36b-f5819006c4d7} executeQuery: Code: 48. DB::Exception: WITH TOTALS and WITH ROLLUP or CUBE are not supported together in presence of HAVING. (NOT_IMPLEMENTED) (version 25.3.6.10636.altinitytest (altinity build)) (from [::1]:40244) (comment: 01122_totals_rollup_having_block_header.sql) (query 6, line 11) (in query: SELECT a, b, count(*) FROM rollup_having GROUP BY a, b WITH ROLLUP WITH TOTALS HAVING a IS NOT NULL;), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000000a074fcb 4. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5477: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000014015684 5. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000140127f9 6. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000014011fce 7. /build/src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000001406ce8a 8. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000014973b42 9. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000001497268d 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000014974d24 11. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001492924b 12. /build/src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88641 13. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 14. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 15. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 16. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 17. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 18. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 19. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 20. ? @ 0x00007fbc6213eac3 21. ? @ 0x00007fbc621d0850 2025.07.28 11:58:57.236955 [ 17371 ] {} TCPHandler: Code: 48. DB::Exception: WITH TOTALS and WITH ROLLUP or CUBE are not supported together in presence of HAVING. (NOT_IMPLEMENTED), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000000a074fcb 4. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5477: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000014015684 5. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000140127f9 6. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000014011fce 7. /build/src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000001406ce8a 8. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000014973b42 9. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000001497268d 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000014974d24 11. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001492924b 12. /build/src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88641 13. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 14. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 15. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 16. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 17. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 18. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 19. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 20. ? @ 0x00007fbc6213eac3 21. ? @ 0x00007fbc621d0850 2025.07.28 11:58:57.267880 [ 17371 ] {940cd0fc-730a-4917-9433-ff50b9e660a6} executeQuery: Code: 48. DB::Exception: WITH TOTALS and WITH ROLLUP or CUBE are not supported together in presence of HAVING. (NOT_IMPLEMENTED) (version 25.3.6.10636.altinitytest (altinity build)) (from [::1]:40244) (comment: 01122_totals_rollup_having_block_header.sql) (query 7, line 12) (in query: SELECT a, b, count(*) FROM rollup_having GROUP BY a, b WITH ROLLUP WITH TOTALS HAVING a IS NOT NULL and b IS NOT NULL;), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000000a074fcb 4. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5477: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000014015684 5. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000140127f9 6. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000014011fce 7. /build/src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000001406ce8a 8. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000014973b42 9. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000001497268d 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000014974d24 11. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001492924b 12. /build/src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88641 13. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 14. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 15. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 16. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 17. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 18. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 19. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 20. ? @ 0x00007fbc6213eac3 21. ? @ 0x00007fbc621d0850 2025.07.28 11:58:57.270531 [ 17371 ] {} TCPHandler: Code: 48. DB::Exception: WITH TOTALS and WITH ROLLUP or CUBE are not supported together in presence of HAVING. (NOT_IMPLEMENTED), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000000a074fcb 4. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5477: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000014015684 5. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000140127f9 6. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000014011fce 7. /build/src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000001406ce8a 8. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000014973b42 9. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000001497268d 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000014974d24 11. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001492924b 12. /build/src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88641 13. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 14. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 15. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 16. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 17. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 18. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 19. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 20. ? @ 0x00007fbc6213eac3 21. ? @ 0x00007fbc621d0850 2025.07.28 11:58:57.638324 [ 3971 ] {} test_13.rmt2 (7f9b740d-015c-470e-8cc6-8ba33be0dc63): auto DB::StorageReplicatedMergeTree::processQueueEntry(ReplicatedMergeTreeQueue::SelectedEntryPtr)::(anonymous class)::operator()(LogEntryPtr &) const: Code: 86. DB::HTTPException: Received error from remote server http://146b4357c08d:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Ftest%2F01165%2Ftest_13%2Frmt%2Freplicas%2F1&part=20250728_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.6.10636.altinitytest (altinity build)) '. (RECEIVED_ERROR_FROM_REMOTE_IO_SERVER), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.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 const&, int&&, String const&, unsigned long&&, String const&) @ 0x000000000feda8d9 4. /build/src/IO/HTTPCommon.cpp:104: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x000000000feda6e2 5. /build/src/IO/HTTPCommon.cpp:93: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x000000000feda537 6. /build/src/IO/ReadWriteBufferFromHTTP.cpp:277: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x000000001184a4c4 7. /build/src/IO/ReadWriteBufferFromHTTP.cpp:285: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x000000001184a615 8. /build/src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x000000001184ae59 9. /build/src/IO/ReadWriteBufferFromHTTP.cpp:472: void std::__function::__policy_invoker::__call_impl[abi:se190107]>(std::__function::__policy_storage const*) @ 0x000000001184cedd 10. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001184858b 11. /build/src/IO/ReadWriteBufferFromHTTP.cpp:465: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x000000001184bf0b 12. /build/src/IO/ReadBuffer.h:60: DB::ReadBuffer::next() @ 0x000000000a148c7b 13. /build/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) @ 0x0000000011849fb2 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]>&)>&, 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&) @ 0x0000000011841980 15. /build/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) @ 0x000000001621208e 16. /build/src/Storages/StorageReplicatedMergeTree.cpp:5228: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl[abi:se190107] const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000015f9a5fe 17. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000015ed8bfd 18. /build/src/Storages/StorageReplicatedMergeTree.cpp:2514: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x0000000015ec9aab 19. /build/src/Storages/StorageReplicatedMergeTree.cpp:2349: DB::StorageReplicatedMergeTree::executeLogEntry(DB::ReplicatedMergeTreeLogEntry&) @ 0x0000000015eba91b 20. /build/src/Storages/StorageReplicatedMergeTree.cpp:3876: bool std::__function::__policy_invoker&)>::__call_impl[abi:se190107])::$_1, bool (std::shared_ptr&)>>(std::__function::__policy_storage const*, std::shared_ptr&) @ 0x0000000015f9837e 21. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000165d6fc3 22. /build/src/Storages/StorageReplicatedMergeTree.cpp:3872: DB::StorageReplicatedMergeTree::processQueueEntry(std::shared_ptr) @ 0x0000000015efc18a 23. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001624c1b2 24. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000162f9c70 25. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x00000000162fa55a 26. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc6653 27. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000000fccc4c3 28. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc3d92 29. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fcca080 30. ? @ 0x00007fbc6213eac3 31. ? @ 0x00007fbc621d0850 (version 25.3.6.10636.altinitytest (altinity build)) 2025.07.28 11:58:58.584189 [ 3966 ] {} test_13.rmt2 (7f9b740d-015c-470e-8cc6-8ba33be0dc63): auto DB::StorageReplicatedMergeTree::processQueueEntry(ReplicatedMergeTreeQueue::SelectedEntryPtr)::(anonymous class)::operator()(LogEntryPtr &) const: Code: 86. DB::HTTPException: Received error from remote server http://146b4357c08d:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Ftest%2F01165%2Ftest_13%2Frmt%2Freplicas%2F1&part=20250728_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.6.10636.altinitytest (altinity build)) '. (RECEIVED_ERROR_FROM_REMOTE_IO_SERVER), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.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 const&, int&&, String const&, unsigned long&&, String const&) @ 0x000000000feda8d9 4. /build/src/IO/HTTPCommon.cpp:104: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x000000000feda6e2 5. /build/src/IO/HTTPCommon.cpp:93: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x000000000feda537 6. /build/src/IO/ReadWriteBufferFromHTTP.cpp:277: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x000000001184a4c4 7. /build/src/IO/ReadWriteBufferFromHTTP.cpp:285: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x000000001184a615 8. /build/src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x000000001184ae59 9. /build/src/IO/ReadWriteBufferFromHTTP.cpp:472: void std::__function::__policy_invoker::__call_impl[abi:se190107]>(std::__function::__policy_storage const*) @ 0x000000001184cedd 10. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001184858b 11. /build/src/IO/ReadWriteBufferFromHTTP.cpp:465: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x000000001184bf0b 12. /build/src/IO/ReadBuffer.h:60: DB::ReadBuffer::next() @ 0x000000000a148c7b 13. /build/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) @ 0x0000000011849fb2 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]>&)>&, 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&) @ 0x0000000011841980 15. /build/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) @ 0x000000001621208e 16. /build/src/Storages/StorageReplicatedMergeTree.cpp:5228: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl[abi:se190107] const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000015f9a5fe 17. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000015ed8bfd 18. /build/src/Storages/StorageReplicatedMergeTree.cpp:2514: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x0000000015ec9aab 19. /build/src/Storages/StorageReplicatedMergeTree.cpp:2349: DB::StorageReplicatedMergeTree::executeLogEntry(DB::ReplicatedMergeTreeLogEntry&) @ 0x0000000015eba91b 20. /build/src/Storages/StorageReplicatedMergeTree.cpp:3876: bool std::__function::__policy_invoker&)>::__call_impl[abi:se190107])::$_1, bool (std::shared_ptr&)>>(std::__function::__policy_storage const*, std::shared_ptr&) @ 0x0000000015f9837e 21. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000165d6fc3 22. /build/src/Storages/StorageReplicatedMergeTree.cpp:3872: DB::StorageReplicatedMergeTree::processQueueEntry(std::shared_ptr) @ 0x0000000015efc18a 23. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001624c1b2 24. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000162f9c70 25. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x00000000162fa55a 26. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc6653 27. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000000fccc4c3 28. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc3d92 29. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fcca080 30. ? @ 0x00007fbc6213eac3 31. ? @ 0x00007fbc621d0850 (version 25.3.6.10636.altinitytest (altinity build)) 2025.07.28 11:58:59.173101 [ 3977 ] {} test_13.rmt2 (7f9b740d-015c-470e-8cc6-8ba33be0dc63): auto DB::StorageReplicatedMergeTree::processQueueEntry(ReplicatedMergeTreeQueue::SelectedEntryPtr)::(anonymous class)::operator()(LogEntryPtr &) const: Code: 86. DB::HTTPException: Received error from remote server http://146b4357c08d:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Ftest%2F01165%2Ftest_13%2Frmt%2Freplicas%2F1&part=20250728_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.6.10636.altinitytest (altinity build)) '. (RECEIVED_ERROR_FROM_REMOTE_IO_SERVER), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.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 const&, int&&, String const&, unsigned long&&, String const&) @ 0x000000000feda8d9 4. /build/src/IO/HTTPCommon.cpp:104: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x000000000feda6e2 5. /build/src/IO/HTTPCommon.cpp:93: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x000000000feda537 6. /build/src/IO/ReadWriteBufferFromHTTP.cpp:277: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x000000001184a4c4 7. /build/src/IO/ReadWriteBufferFromHTTP.cpp:285: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x000000001184a615 8. /build/src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x000000001184ae59 9. /build/src/IO/ReadWriteBufferFromHTTP.cpp:472: void std::__function::__policy_invoker::__call_impl[abi:se190107]>(std::__function::__policy_storage const*) @ 0x000000001184cedd 10. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001184858b 11. /build/src/IO/ReadWriteBufferFromHTTP.cpp:465: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x000000001184bf0b 12. /build/src/IO/ReadBuffer.h:60: DB::ReadBuffer::next() @ 0x000000000a148c7b 13. /build/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) @ 0x0000000011849fb2 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]>&)>&, 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&) @ 0x0000000011841980 15. /build/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) @ 0x000000001621208e 16. /build/src/Storages/StorageReplicatedMergeTree.cpp:5228: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl[abi:se190107] const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000015f9a5fe 17. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000015ed8bfd 18. /build/src/Storages/StorageReplicatedMergeTree.cpp:2514: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x0000000015ec9aab 19. /build/src/Storages/StorageReplicatedMergeTree.cpp:2349: DB::StorageReplicatedMergeTree::executeLogEntry(DB::ReplicatedMergeTreeLogEntry&) @ 0x0000000015eba91b 20. /build/src/Storages/StorageReplicatedMergeTree.cpp:3876: bool std::__function::__policy_invoker&)>::__call_impl[abi:se190107])::$_1, bool (std::shared_ptr&)>>(std::__function::__policy_storage const*, std::shared_ptr&) @ 0x0000000015f9837e 21. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000165d6fc3 22. /build/src/Storages/StorageReplicatedMergeTree.cpp:3872: DB::StorageReplicatedMergeTree::processQueueEntry(std::shared_ptr) @ 0x0000000015efc18a 23. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001624c1b2 24. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000162f9c70 25. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x00000000162fa55a 26. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc6653 27. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000000fccc4c3 28. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc3d92 29. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fcca080 30. ? @ 0x00007fbc6213eac3 31. ? @ 0x00007fbc621d0850 (version 25.3.6.10636.altinitytest (altinity build)) 2025.07.28 11:58:59.510868 [ 3969 ] {} test_13.rmt2 (7f9b740d-015c-470e-8cc6-8ba33be0dc63): auto DB::StorageReplicatedMergeTree::processQueueEntry(ReplicatedMergeTreeQueue::SelectedEntryPtr)::(anonymous class)::operator()(LogEntryPtr &) const: Code: 86. DB::HTTPException: Received error from remote server http://146b4357c08d:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Ftest%2F01165%2Ftest_13%2Frmt%2Freplicas%2F1&part=20250728_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.6.10636.altinitytest (altinity build)) '. (RECEIVED_ERROR_FROM_REMOTE_IO_SERVER), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.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 const&, int&&, String const&, unsigned long&&, String const&) @ 0x000000000feda8d9 4. /build/src/IO/HTTPCommon.cpp:104: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x000000000feda6e2 5. /build/src/IO/HTTPCommon.cpp:93: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x000000000feda537 6. /build/src/IO/ReadWriteBufferFromHTTP.cpp:277: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x000000001184a4c4 7. /build/src/IO/ReadWriteBufferFromHTTP.cpp:285: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x000000001184a615 8. /build/src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x000000001184ae59 9. /build/src/IO/ReadWriteBufferFromHTTP.cpp:472: void std::__function::__policy_invoker::__call_impl[abi:se190107]>(std::__function::__policy_storage const*) @ 0x000000001184cedd 10. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001184858b 11. /build/src/IO/ReadWriteBufferFromHTTP.cpp:465: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x000000001184bf0b 12. /build/src/IO/ReadBuffer.h:60: DB::ReadBuffer::next() @ 0x000000000a148c7b 13. /build/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) @ 0x0000000011849fb2 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]>&)>&, 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&) @ 0x0000000011841980 15. /build/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) @ 0x000000001621208e 16. /build/src/Storages/StorageReplicatedMergeTree.cpp:5228: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl[abi:se190107] const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000015f9a5fe 17. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000015ed8bfd 18. /build/src/Storages/StorageReplicatedMergeTree.cpp:2514: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x0000000015ec9aab 19. /build/src/Storages/StorageReplicatedMergeTree.cpp:2349: DB::StorageReplicatedMergeTree::executeLogEntry(DB::ReplicatedMergeTreeLogEntry&) @ 0x0000000015eba91b 20. /build/src/Storages/StorageReplicatedMergeTree.cpp:3876: bool std::__function::__policy_invoker&)>::__call_impl[abi:se190107])::$_1, bool (std::shared_ptr&)>>(std::__function::__policy_storage const*, std::shared_ptr&) @ 0x0000000015f9837e 21. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000165d6fc3 22. /build/src/Storages/StorageReplicatedMergeTree.cpp:3872: DB::StorageReplicatedMergeTree::processQueueEntry(std::shared_ptr) @ 0x0000000015efc18a 23. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001624c1b2 24. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000162f9c70 25. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x00000000162fa55a 26. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc6653 27. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000000fccc4c3 28. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc3d92 29. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fcca080 30. ? @ 0x00007fbc6213eac3 31. ? @ 0x00007fbc621d0850 (version 25.3.6.10636.altinitytest (altinity build)) 2025.07.28 11:58:59.719904 [ 3967 ] {} test_13.rmt2 (7f9b740d-015c-470e-8cc6-8ba33be0dc63): auto DB::StorageReplicatedMergeTree::processQueueEntry(ReplicatedMergeTreeQueue::SelectedEntryPtr)::(anonymous class)::operator()(LogEntryPtr &) const: Code: 86. DB::HTTPException: Received error from remote server http://146b4357c08d:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Ftest%2F01165%2Ftest_13%2Frmt%2Freplicas%2F1&part=20250728_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.6.10636.altinitytest (altinity build)) '. (RECEIVED_ERROR_FROM_REMOTE_IO_SERVER), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.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 const&, int&&, String const&, unsigned long&&, String const&) @ 0x000000000feda8d9 4. /build/src/IO/HTTPCommon.cpp:104: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x000000000feda6e2 5. /build/src/IO/HTTPCommon.cpp:93: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x000000000feda537 6. /build/src/IO/ReadWriteBufferFromHTTP.cpp:277: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x000000001184a4c4 7. /build/src/IO/ReadWriteBufferFromHTTP.cpp:285: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x000000001184a615 8. /build/src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x000000001184ae59 9. /build/src/IO/ReadWriteBufferFromHTTP.cpp:472: void std::__function::__policy_invoker::__call_impl[abi:se190107]>(std::__function::__policy_storage const*) @ 0x000000001184cedd 10. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001184858b 11. /build/src/IO/ReadWriteBufferFromHTTP.cpp:465: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x000000001184bf0b 12. /build/src/IO/ReadBuffer.h:60: DB::ReadBuffer::next() @ 0x000000000a148c7b 13. /build/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) @ 0x0000000011849fb2 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]>&)>&, 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&) @ 0x0000000011841980 15. /build/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) @ 0x000000001621208e 16. /build/src/Storages/StorageReplicatedMergeTree.cpp:5228: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl[abi:se190107] const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000015f9a5fe 17. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000015ed8bfd 18. /build/src/Storages/StorageReplicatedMergeTree.cpp:2514: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x0000000015ec9aab 19. /build/src/Storages/StorageReplicatedMergeTree.cpp:2349: DB::StorageReplicatedMergeTree::executeLogEntry(DB::ReplicatedMergeTreeLogEntry&) @ 0x0000000015eba91b 20. /build/src/Storages/StorageReplicatedMergeTree.cpp:3876: bool std::__function::__policy_invoker&)>::__call_impl[abi:se190107])::$_1, bool (std::shared_ptr&)>>(std::__function::__policy_storage const*, std::shared_ptr&) @ 0x0000000015f9837e 21. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000165d6fc3 22. /build/src/Storages/StorageReplicatedMergeTree.cpp:3872: DB::StorageReplicatedMergeTree::processQueueEntry(std::shared_ptr) @ 0x0000000015efc18a 23. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001624c1b2 24. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000162f9c70 25. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x00000000162fa55a 26. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc6653 27. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000000fccc4c3 28. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc3d92 29. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fcca080 30. ? @ 0x00007fbc6213eac3 31. ? @ 0x00007fbc621d0850 (version 25.3.6.10636.altinitytest (altinity build)) 2025.07.28 11:58:59.860712 [ 3965 ] {} test_13.rmt2 (7f9b740d-015c-470e-8cc6-8ba33be0dc63): auto DB::StorageReplicatedMergeTree::processQueueEntry(ReplicatedMergeTreeQueue::SelectedEntryPtr)::(anonymous class)::operator()(LogEntryPtr &) const: Code: 86. DB::HTTPException: Received error from remote server http://146b4357c08d:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Ftest%2F01165%2Ftest_13%2Frmt%2Freplicas%2F1&part=20250728_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.6.10636.altinitytest (altinity build)) '. (RECEIVED_ERROR_FROM_REMOTE_IO_SERVER), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.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 const&, int&&, String const&, unsigned long&&, String const&) @ 0x000000000feda8d9 4. /build/src/IO/HTTPCommon.cpp:104: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x000000000feda6e2 5. /build/src/IO/HTTPCommon.cpp:93: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x000000000feda537 6. /build/src/IO/ReadWriteBufferFromHTTP.cpp:277: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x000000001184a4c4 7. /build/src/IO/ReadWriteBufferFromHTTP.cpp:285: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x000000001184a615 8. /build/src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x000000001184ae59 9. /build/src/IO/ReadWriteBufferFromHTTP.cpp:472: void std::__function::__policy_invoker::__call_impl[abi:se190107]>(std::__function::__policy_storage const*) @ 0x000000001184cedd 10. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001184858b 11. /build/src/IO/ReadWriteBufferFromHTTP.cpp:465: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x000000001184bf0b 12. /build/src/IO/ReadBuffer.h:60: DB::ReadBuffer::next() @ 0x000000000a148c7b 13. /build/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) @ 0x0000000011849fb2 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]>&)>&, 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&) @ 0x0000000011841980 15. /build/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) @ 0x000000001621208e 16. /build/src/Storages/StorageReplicatedMergeTree.cpp:5228: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl[abi:se190107] const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000015f9a5fe 17. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000015ed8bfd 18. /build/src/Storages/StorageReplicatedMergeTree.cpp:2514: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x0000000015ec9aab 19. /build/src/Storages/StorageReplicatedMergeTree.cpp:2349: DB::StorageReplicatedMergeTree::executeLogEntry(DB::ReplicatedMergeTreeLogEntry&) @ 0x0000000015eba91b 20. /build/src/Storages/StorageReplicatedMergeTree.cpp:3876: bool std::__function::__policy_invoker&)>::__call_impl[abi:se190107])::$_1, bool (std::shared_ptr&)>>(std::__function::__policy_storage const*, std::shared_ptr&) @ 0x0000000015f9837e 21. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000165d6fc3 22. /build/src/Storages/StorageReplicatedMergeTree.cpp:3872: DB::StorageReplicatedMergeTree::processQueueEntry(std::shared_ptr) @ 0x0000000015efc18a 23. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001624c1b2 24. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000162f9c70 25. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x00000000162fa55a 26. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc6653 27. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000000fccc4c3 28. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc3d92 29. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fcca080 30. ? @ 0x00007fbc6213eac3 31. ? @ 0x00007fbc621d0850 (version 25.3.6.10636.altinitytest (altinity build)) 2025.07.28 11:59:00.303655 [ 3977 ] {} test_13.rmt2 (7f9b740d-015c-470e-8cc6-8ba33be0dc63): auto DB::StorageReplicatedMergeTree::processQueueEntry(ReplicatedMergeTreeQueue::SelectedEntryPtr)::(anonymous class)::operator()(LogEntryPtr &) const: Code: 86. DB::HTTPException: Received error from remote server http://146b4357c08d:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Ftest%2F01165%2Ftest_13%2Frmt%2Freplicas%2F1&part=20250728_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.6.10636.altinitytest (altinity build)) '. (RECEIVED_ERROR_FROM_REMOTE_IO_SERVER), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.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 const&, int&&, String const&, unsigned long&&, String const&) @ 0x000000000feda8d9 4. /build/src/IO/HTTPCommon.cpp:104: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x000000000feda6e2 5. /build/src/IO/HTTPCommon.cpp:93: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x000000000feda537 6. /build/src/IO/ReadWriteBufferFromHTTP.cpp:277: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x000000001184a4c4 7. /build/src/IO/ReadWriteBufferFromHTTP.cpp:285: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x000000001184a615 8. /build/src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x000000001184ae59 9. /build/src/IO/ReadWriteBufferFromHTTP.cpp:472: void std::__function::__policy_invoker::__call_impl[abi:se190107]>(std::__function::__policy_storage const*) @ 0x000000001184cedd 10. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001184858b 11. /build/src/IO/ReadWriteBufferFromHTTP.cpp:465: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x000000001184bf0b 12. /build/src/IO/ReadBuffer.h:60: DB::ReadBuffer::next() @ 0x000000000a148c7b 13. /build/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) @ 0x0000000011849fb2 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]>&)>&, 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&) @ 0x0000000011841980 15. /build/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) @ 0x000000001621208e 16. /build/src/Storages/StorageReplicatedMergeTree.cpp:5228: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl[abi:se190107] const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000015f9a5fe 17. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000015ed8bfd 18. /build/src/Storages/StorageReplicatedMergeTree.cpp:2514: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x0000000015ec9aab 19. /build/src/Storages/StorageReplicatedMergeTree.cpp:2349: DB::StorageReplicatedMergeTree::executeLogEntry(DB::ReplicatedMergeTreeLogEntry&) @ 0x0000000015eba91b 20. /build/src/Storages/StorageReplicatedMergeTree.cpp:3876: bool std::__function::__policy_invoker&)>::__call_impl[abi:se190107])::$_1, bool (std::shared_ptr&)>>(std::__function::__policy_storage const*, std::shared_ptr&) @ 0x0000000015f9837e 21. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000165d6fc3 22. /build/src/Storages/StorageReplicatedMergeTree.cpp:3872: DB::StorageReplicatedMergeTree::processQueueEntry(std::shared_ptr) @ 0x0000000015efc18a 23. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001624c1b2 24. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000162f9c70 25. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x00000000162fa55a 26. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc6653 27. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000000fccc4c3 28. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc3d92 29. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fcca080 30. ? @ 0x00007fbc6213eac3 31. ? @ 0x00007fbc621d0850 (version 25.3.6.10636.altinitytest (altinity build)) 2025.07.28 11:59:00.706478 [ 3961 ] {} test_13.rmt2 (7f9b740d-015c-470e-8cc6-8ba33be0dc63): auto DB::StorageReplicatedMergeTree::processQueueEntry(ReplicatedMergeTreeQueue::SelectedEntryPtr)::(anonymous class)::operator()(LogEntryPtr &) const: Code: 86. DB::HTTPException: Received error from remote server http://146b4357c08d:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Ftest%2F01165%2Ftest_13%2Frmt%2Freplicas%2F1&part=20250728_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.6.10636.altinitytest (altinity build)) '. (RECEIVED_ERROR_FROM_REMOTE_IO_SERVER), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.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 const&, int&&, String const&, unsigned long&&, String const&) @ 0x000000000feda8d9 4. /build/src/IO/HTTPCommon.cpp:104: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x000000000feda6e2 5. /build/src/IO/HTTPCommon.cpp:93: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x000000000feda537 6. /build/src/IO/ReadWriteBufferFromHTTP.cpp:277: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x000000001184a4c4 7. /build/src/IO/ReadWriteBufferFromHTTP.cpp:285: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x000000001184a615 8. /build/src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x000000001184ae59 9. /build/src/IO/ReadWriteBufferFromHTTP.cpp:472: void std::__function::__policy_invoker::__call_impl[abi:se190107]>(std::__function::__policy_storage const*) @ 0x000000001184cedd 10. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001184858b 11. /build/src/IO/ReadWriteBufferFromHTTP.cpp:465: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x000000001184bf0b 12. /build/src/IO/ReadBuffer.h:60: DB::ReadBuffer::next() @ 0x000000000a148c7b 13. /build/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) @ 0x0000000011849fb2 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]>&)>&, 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&) @ 0x0000000011841980 15. /build/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) @ 0x000000001621208e 16. /build/src/Storages/StorageReplicatedMergeTree.cpp:5228: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl[abi:se190107] const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000015f9a5fe 17. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000015ed8bfd 18. /build/src/Storages/StorageReplicatedMergeTree.cpp:2514: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x0000000015ec9aab 19. /build/src/Storages/StorageReplicatedMergeTree.cpp:2349: DB::StorageReplicatedMergeTree::executeLogEntry(DB::ReplicatedMergeTreeLogEntry&) @ 0x0000000015eba91b 20. /build/src/Storages/StorageReplicatedMergeTree.cpp:3876: bool std::__function::__policy_invoker&)>::__call_impl[abi:se190107])::$_1, bool (std::shared_ptr&)>>(std::__function::__policy_storage const*, std::shared_ptr&) @ 0x0000000015f9837e 21. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000165d6fc3 22. /build/src/Storages/StorageReplicatedMergeTree.cpp:3872: DB::StorageReplicatedMergeTree::processQueueEntry(std::shared_ptr) @ 0x0000000015efc18a 23. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001624c1b2 24. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000162f9c70 25. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x00000000162fa55a 26. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc6653 27. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000000fccc4c3 28. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc3d92 29. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fcca080 30. ? @ 0x00007fbc6213eac3 31. ? @ 0x00007fbc621d0850 (version 25.3.6.10636.altinitytest (altinity build)) 2025.07.28 11:59:00.943167 [ 3974 ] {} test_13.rmt2 (7f9b740d-015c-470e-8cc6-8ba33be0dc63): auto DB::StorageReplicatedMergeTree::processQueueEntry(ReplicatedMergeTreeQueue::SelectedEntryPtr)::(anonymous class)::operator()(LogEntryPtr &) const: Code: 86. DB::HTTPException: Received error from remote server http://146b4357c08d:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Ftest%2F01165%2Ftest_13%2Frmt%2Freplicas%2F1&part=20250728_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.6.10636.altinitytest (altinity build)) '. (RECEIVED_ERROR_FROM_REMOTE_IO_SERVER), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.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 const&, int&&, String const&, unsigned long&&, String const&) @ 0x000000000feda8d9 4. /build/src/IO/HTTPCommon.cpp:104: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x000000000feda6e2 5. /build/src/IO/HTTPCommon.cpp:93: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x000000000feda537 6. /build/src/IO/ReadWriteBufferFromHTTP.cpp:277: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x000000001184a4c4 7. /build/src/IO/ReadWriteBufferFromHTTP.cpp:285: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x000000001184a615 8. /build/src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x000000001184ae59 9. /build/src/IO/ReadWriteBufferFromHTTP.cpp:472: void std::__function::__policy_invoker::__call_impl[abi:se190107]>(std::__function::__policy_storage const*) @ 0x000000001184cedd 10. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001184858b 11. /build/src/IO/ReadWriteBufferFromHTTP.cpp:465: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x000000001184bf0b 12. /build/src/IO/ReadBuffer.h:60: DB::ReadBuffer::next() @ 0x000000000a148c7b 13. /build/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) @ 0x0000000011849fb2 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]>&)>&, 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&) @ 0x0000000011841980 15. /build/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) @ 0x000000001621208e 16. /build/src/Storages/StorageReplicatedMergeTree.cpp:5228: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl[abi:se190107] const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000015f9a5fe 17. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000015ed8bfd 18. /build/src/Storages/StorageReplicatedMergeTree.cpp:2514: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x0000000015ec9aab 19. /build/src/Storages/StorageReplicatedMergeTree.cpp:2349: DB::StorageReplicatedMergeTree::executeLogEntry(DB::ReplicatedMergeTreeLogEntry&) @ 0x0000000015eba91b 20. /build/src/Storages/StorageReplicatedMergeTree.cpp:3876: bool std::__function::__policy_invoker&)>::__call_impl[abi:se190107])::$_1, bool (std::shared_ptr&)>>(std::__function::__policy_storage const*, std::shared_ptr&) @ 0x0000000015f9837e 21. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000165d6fc3 22. /build/src/Storages/StorageReplicatedMergeTree.cpp:3872: DB::StorageReplicatedMergeTree::processQueueEntry(std::shared_ptr) @ 0x0000000015efc18a 23. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001624c1b2 24. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000162f9c70 25. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x00000000162fa55a 26. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc6653 27. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000000fccc4c3 28. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc3d92 29. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fcca080 30. ? @ 0x00007fbc6213eac3 31. ? @ 0x00007fbc621d0850 (version 25.3.6.10636.altinitytest (altinity build)) 2025.07.28 11:59:01.157757 [ 17371 ] {} 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. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception>&, String>(int, FormatStringHelperImpl>&>::type, std::type_identity::type>, std::basic_string_view>&, String&&) @ 0x000000001385a5eb 4. /build/src/Access/SettingsConstraints.cpp:376: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000013859b18 5. /build/src/Access/SettingsConstraints.cpp:300: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000013858faf 6. /build/src/Access/SettingsConstraints.cpp:209: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000013859223 7. /build/src/Interpreters/Context.cpp:2690: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000014436134 8. /build/src/Interpreters/Context.cpp:2729: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x000000001443662b 9. /build/src/Server/HTTPHandler.cpp:457: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000001686d165 10. /build/src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x0000000016870807 11. /build/src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x0000000016907e99 12. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 13. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 14. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 15. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 16. ? @ 0x00007fbc6213eac3 17. ? @ 0x00007fbc621d0850 (version 25.3.6.10636.altinitytest (altinity build)) 2025.07.28 11:59:01.317313 [ 3970 ] {} test_13.rmt2 (7f9b740d-015c-470e-8cc6-8ba33be0dc63): auto DB::StorageReplicatedMergeTree::processQueueEntry(ReplicatedMergeTreeQueue::SelectedEntryPtr)::(anonymous class)::operator()(LogEntryPtr &) const: Code: 86. DB::HTTPException: Received error from remote server http://146b4357c08d:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Ftest%2F01165%2Ftest_13%2Frmt%2Freplicas%2F1&part=20250728_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.6.10636.altinitytest (altinity build)) '. (RECEIVED_ERROR_FROM_REMOTE_IO_SERVER), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.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 const&, int&&, String const&, unsigned long&&, String const&) @ 0x000000000feda8d9 4. /build/src/IO/HTTPCommon.cpp:104: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x000000000feda6e2 5. /build/src/IO/HTTPCommon.cpp:93: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x000000000feda537 6. /build/src/IO/ReadWriteBufferFromHTTP.cpp:277: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x000000001184a4c4 7. /build/src/IO/ReadWriteBufferFromHTTP.cpp:285: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x000000001184a615 8. /build/src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x000000001184ae59 9. /build/src/IO/ReadWriteBufferFromHTTP.cpp:472: void std::__function::__policy_invoker::__call_impl[abi:se190107]>(std::__function::__policy_storage const*) @ 0x000000001184cedd 10. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001184858b 11. /build/src/IO/ReadWriteBufferFromHTTP.cpp:465: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x000000001184bf0b 12. /build/src/IO/ReadBuffer.h:60: DB::ReadBuffer::next() @ 0x000000000a148c7b 13. /build/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) @ 0x0000000011849fb2 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]>&)>&, 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&) @ 0x0000000011841980 15. /build/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) @ 0x000000001621208e 16. /build/src/Storages/StorageReplicatedMergeTree.cpp:5228: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl[abi:se190107] const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000015f9a5fe 17. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000015ed8bfd 18. /build/src/Storages/StorageReplicatedMergeTree.cpp:2514: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x0000000015ec9aab 19. /build/src/Storages/StorageReplicatedMergeTree.cpp:2349: DB::StorageReplicatedMergeTree::executeLogEntry(DB::ReplicatedMergeTreeLogEntry&) @ 0x0000000015eba91b 20. /build/src/Storages/StorageReplicatedMergeTree.cpp:3876: bool std::__function::__policy_invoker&)>::__call_impl[abi:se190107])::$_1, bool (std::shared_ptr&)>>(std::__function::__policy_storage const*, std::shared_ptr&) @ 0x0000000015f9837e 21. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000165d6fc3 22. /build/src/Storages/StorageReplicatedMergeTree.cpp:3872: DB::StorageReplicatedMergeTree::processQueueEntry(std::shared_ptr) @ 0x0000000015efc18a 23. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001624c1b2 24. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000162f9c70 25. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x00000000162fa55a 26. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc6653 27. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000000fccc4c3 28. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc3d92 29. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fcca080 30. ? @ 0x00007fbc6213eac3 31. ? @ 0x00007fbc621d0850 (version 25.3.6.10636.altinitytest (altinity build)) 2025.07.28 11:59:02.062992 [ 17371 ] {} 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. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception>&, String>(int, FormatStringHelperImpl>&>::type, std::type_identity::type>, std::basic_string_view>&, String&&) @ 0x000000001385a5eb 4. /build/src/Access/SettingsConstraints.cpp:376: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000013859b18 5. /build/src/Access/SettingsConstraints.cpp:300: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000013858faf 6. /build/src/Access/SettingsConstraints.cpp:209: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000013859223 7. /build/src/Interpreters/Context.cpp:2690: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000014436134 8. /build/src/Interpreters/Context.cpp:2729: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x000000001443662b 9. /build/src/Server/HTTPHandler.cpp:457: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000001686d165 10. /build/src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x0000000016870807 11. /build/src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x0000000016907e99 12. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 13. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 14. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 15. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 16. ? @ 0x00007fbc6213eac3 17. ? @ 0x00007fbc621d0850 (version 25.3.6.10636.altinitytest (altinity build)) 2025.07.28 11:59:02.315547 [ 3969 ] {} test_13.rmt2 (7f9b740d-015c-470e-8cc6-8ba33be0dc63): auto DB::StorageReplicatedMergeTree::processQueueEntry(ReplicatedMergeTreeQueue::SelectedEntryPtr)::(anonymous class)::operator()(LogEntryPtr &) const: Code: 86. DB::HTTPException: Received error from remote server http://146b4357c08d:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Ftest%2F01165%2Ftest_13%2Frmt%2Freplicas%2F1&part=20250728_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.6.10636.altinitytest (altinity build)) '. (RECEIVED_ERROR_FROM_REMOTE_IO_SERVER), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.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 const&, int&&, String const&, unsigned long&&, String const&) @ 0x000000000feda8d9 4. /build/src/IO/HTTPCommon.cpp:104: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x000000000feda6e2 5. /build/src/IO/HTTPCommon.cpp:93: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x000000000feda537 6. /build/src/IO/ReadWriteBufferFromHTTP.cpp:277: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x000000001184a4c4 7. /build/src/IO/ReadWriteBufferFromHTTP.cpp:285: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x000000001184a615 8. /build/src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x000000001184ae59 9. /build/src/IO/ReadWriteBufferFromHTTP.cpp:472: void std::__function::__policy_invoker::__call_impl[abi:se190107]>(std::__function::__policy_storage const*) @ 0x000000001184cedd 10. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001184858b 11. /build/src/IO/ReadWriteBufferFromHTTP.cpp:465: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x000000001184bf0b 12. /build/src/IO/ReadBuffer.h:60: DB::ReadBuffer::next() @ 0x000000000a148c7b 13. /build/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) @ 0x0000000011849fb2 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]>&)>&, 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&) @ 0x0000000011841980 15. /build/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) @ 0x000000001621208e 16. /build/src/Storages/StorageReplicatedMergeTree.cpp:5228: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl[abi:se190107] const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000015f9a5fe 17. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000015ed8bfd 18. /build/src/Storages/StorageReplicatedMergeTree.cpp:2514: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x0000000015ec9aab 19. /build/src/Storages/StorageReplicatedMergeTree.cpp:2349: DB::StorageReplicatedMergeTree::executeLogEntry(DB::ReplicatedMergeTreeLogEntry&) @ 0x0000000015eba91b 20. /build/src/Storages/StorageReplicatedMergeTree.cpp:3876: bool std::__function::__policy_invoker&)>::__call_impl[abi:se190107])::$_1, bool (std::shared_ptr&)>>(std::__function::__policy_storage const*, std::shared_ptr&) @ 0x0000000015f9837e 21. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000165d6fc3 22. /build/src/Storages/StorageReplicatedMergeTree.cpp:3872: DB::StorageReplicatedMergeTree::processQueueEntry(std::shared_ptr) @ 0x0000000015efc18a 23. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001624c1b2 24. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000162f9c70 25. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x00000000162fa55a 26. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc6653 27. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000000fccc4c3 28. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc3d92 29. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fcca080 30. ? @ 0x00007fbc6213eac3 31. ? @ 0x00007fbc621d0850 (version 25.3.6.10636.altinitytest (altinity build)) 2025.07.28 11:59:02.882488 [ 3971 ] {} test_13.rmt2 (7f9b740d-015c-470e-8cc6-8ba33be0dc63): auto DB::StorageReplicatedMergeTree::processQueueEntry(ReplicatedMergeTreeQueue::SelectedEntryPtr)::(anonymous class)::operator()(LogEntryPtr &) const: Code: 86. DB::HTTPException: Received error from remote server http://146b4357c08d:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Ftest%2F01165%2Ftest_13%2Frmt%2Freplicas%2F1&part=20250728_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.6.10636.altinitytest (altinity build)) '. (RECEIVED_ERROR_FROM_REMOTE_IO_SERVER), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.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 const&, int&&, String const&, unsigned long&&, String const&) @ 0x000000000feda8d9 4. /build/src/IO/HTTPCommon.cpp:104: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x000000000feda6e2 5. /build/src/IO/HTTPCommon.cpp:93: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x000000000feda537 6. /build/src/IO/ReadWriteBufferFromHTTP.cpp:277: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x000000001184a4c4 7. /build/src/IO/ReadWriteBufferFromHTTP.cpp:285: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x000000001184a615 8. /build/src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x000000001184ae59 9. /build/src/IO/ReadWriteBufferFromHTTP.cpp:472: void std::__function::__policy_invoker::__call_impl[abi:se190107]>(std::__function::__policy_storage const*) @ 0x000000001184cedd 10. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001184858b 11. /build/src/IO/ReadWriteBufferFromHTTP.cpp:465: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x000000001184bf0b 12. /build/src/IO/ReadBuffer.h:60: DB::ReadBuffer::next() @ 0x000000000a148c7b 13. /build/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) @ 0x0000000011849fb2 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]>&)>&, 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&) @ 0x0000000011841980 15. /build/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) @ 0x000000001621208e 16. /build/src/Storages/StorageReplicatedMergeTree.cpp:5228: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl[abi:se190107] const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000015f9a5fe 17. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000015ed8bfd 18. /build/src/Storages/StorageReplicatedMergeTree.cpp:2514: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x0000000015ec9aab 19. /build/src/Storages/StorageReplicatedMergeTree.cpp:2349: DB::StorageReplicatedMergeTree::executeLogEntry(DB::ReplicatedMergeTreeLogEntry&) @ 0x0000000015eba91b 20. /build/src/Storages/StorageReplicatedMergeTree.cpp:3876: bool std::__function::__policy_invoker&)>::__call_impl[abi:se190107])::$_1, bool (std::shared_ptr&)>>(std::__function::__policy_storage const*, std::shared_ptr&) @ 0x0000000015f9837e 21. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000165d6fc3 22. /build/src/Storages/StorageReplicatedMergeTree.cpp:3872: DB::StorageReplicatedMergeTree::processQueueEntry(std::shared_ptr) @ 0x0000000015efc18a 23. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001624c1b2 24. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000162f9c70 25. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x00000000162fa55a 26. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc6653 27. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000000fccc4c3 28. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc3d92 29. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fcca080 30. ? @ 0x00007fbc6213eac3 31. ? @ 0x00007fbc621d0850 (version 25.3.6.10636.altinitytest (altinity build)) 2025.07.28 11:59:03.407679 [ 17371 ] {} 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. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception>&, String>(int, FormatStringHelperImpl>&>::type, std::type_identity::type>, std::basic_string_view>&, String&&) @ 0x000000001385a5eb 4. /build/src/Access/SettingsConstraints.cpp:376: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000013859b18 5. /build/src/Access/SettingsConstraints.cpp:300: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000013858faf 6. /build/src/Access/SettingsConstraints.cpp:209: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000013859223 7. /build/src/Interpreters/Context.cpp:2690: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000014436134 8. /build/src/Interpreters/Context.cpp:2729: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x000000001443662b 9. /build/src/Server/HTTPHandler.cpp:457: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000001686d165 10. /build/src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x0000000016870807 11. /build/src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x0000000016907e99 12. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 13. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 14. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 15. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 16. ? @ 0x00007fbc6213eac3 17. ? @ 0x00007fbc621d0850 (version 25.3.6.10636.altinitytest (altinity build)) 2025.07.28 11:59:03.668830 [ 17256 ] {4d4a2720-a25c-4809-babf-a51652470863} executeQuery: Code: 439. DB::Exception: Cannot schedule a task: failed to start the thread (threads=0, jobs=0). (CANNOT_SCHEDULE_TASK) (version 25.3.6.10636.altinitytest (altinity build)) (from [::1]:51154) (comment: 02932_parallel_replicas_fuzzer.sql) (query 5, line 16) (in query: CREATE TABLE t_02709__fuzz_23 (`key` Nullable(UInt8), `sign` Int8, `date` DateTime64(3)) ENGINE = CollapsingMergeTree(sign) PARTITION BY date ORDER BY key SETTINGS allow_nullable_key = 1, index_granularity = 13270, min_bytes_for_wide_part = 0, ratio_of_defaults_for_sparse_serialization = 0., replace_long_file_name_to_hash = false, max_file_name_length = 83, min_bytes_for_full_part_storage = 370948202, compact_parts_max_bytes_to_buffer = 1627745, compact_parts_max_granules_to_buffer = 68, compact_parts_merge_max_bytes_to_prefetch_part = 18230826, merge_max_block_size = 13245, old_parts_lifetime = 460., prefer_fetch_merged_part_size_threshold = 8105456171, 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 = 23237695, use_const_adaptive_granularity = false, enable_index_granularity_compression = false, concurrent_part_removal_threshold = 12, 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 = 84693, primary_key_compress_block_size = 42424, 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. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000fccaeeb 4. /build/src/Common/ThreadPool.cpp:275: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000fccc813 5. /build/src/Common/ThreadPool.cpp:308: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fcc8286 6. /build/src/Common/ThreadPool.cpp:494: ThreadPoolImpl>::scheduleOrThrowOnError(std::function, Priority) @ 0x000000000fcc7a0e 7. /build/src/Common/threadPoolCallbackRunner.h:188: DB::ThreadPoolCallbackRunnerLocal>, std::function>::operator()(std::function&&, Priority, std::optional) @ 0x00000000119df78e 8. /build/src/Storages/MergeTree/MergeTreeData.cpp:1923: DB::MergeTreeData::loadDataParts(bool, std::optional, std::equal_to, std::allocator>>) @ 0x0000000016314fbd 9. /build/src/Storages/StorageMergeTree.cpp:161: 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>) @ 0x0000000016632c15 10. /build/contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: std::shared_ptr std::allocate_shared[abi:se190107], 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>&&) @ 0x00000000166326f0 11. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:851: DB::create(DB::StorageFactory::Arguments const&) @ 0x000000001662f01d 12. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000015d81ea2 13. /build/src/Interpreters/InterpreterCreateQuery.cpp:1945: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x00000000149009bb 14. /build/src/Interpreters/InterpreterCreateQuery.cpp:1743: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000148f9aa9 15. /build/src/Interpreters/InterpreterCreateQuery.cpp:2352: DB::InterpreterCreateQuery::execute() @ 0x0000000014905a41 16. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88dc9 17. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 18. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 19. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 20. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 21. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 22. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 23. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 24. ? @ 0x00007fbc6213eac3 25. ? @ 0x00007fbc621d0850 2025.07.28 11:59:03.673928 [ 17256 ] {} 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. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000fccaeeb 4. /build/src/Common/ThreadPool.cpp:275: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000fccc813 5. /build/src/Common/ThreadPool.cpp:308: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fcc8286 6. /build/src/Common/ThreadPool.cpp:494: ThreadPoolImpl>::scheduleOrThrowOnError(std::function, Priority) @ 0x000000000fcc7a0e 7. /build/src/Common/threadPoolCallbackRunner.h:188: DB::ThreadPoolCallbackRunnerLocal>, std::function>::operator()(std::function&&, Priority, std::optional) @ 0x00000000119df78e 8. /build/src/Storages/MergeTree/MergeTreeData.cpp:1923: DB::MergeTreeData::loadDataParts(bool, std::optional, std::equal_to, std::allocator>>) @ 0x0000000016314fbd 9. /build/src/Storages/StorageMergeTree.cpp:161: 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>) @ 0x0000000016632c15 10. /build/contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: std::shared_ptr std::allocate_shared[abi:se190107], 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>&&) @ 0x00000000166326f0 11. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:851: DB::create(DB::StorageFactory::Arguments const&) @ 0x000000001662f01d 12. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000015d81ea2 13. /build/src/Interpreters/InterpreterCreateQuery.cpp:1945: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x00000000149009bb 14. /build/src/Interpreters/InterpreterCreateQuery.cpp:1743: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000148f9aa9 15. /build/src/Interpreters/InterpreterCreateQuery.cpp:2352: DB::InterpreterCreateQuery::execute() @ 0x0000000014905a41 16. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88dc9 17. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 18. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 19. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 20. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 21. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 22. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 23. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 24. ? @ 0x00007fbc6213eac3 25. ? @ 0x00007fbc621d0850 2025.07.28 11:59:03.718654 [ 3960 ] {} test_13.rmt2 (7f9b740d-015c-470e-8cc6-8ba33be0dc63): auto DB::StorageReplicatedMergeTree::processQueueEntry(ReplicatedMergeTreeQueue::SelectedEntryPtr)::(anonymous class)::operator()(LogEntryPtr &) const: Code: 86. DB::HTTPException: Received error from remote server http://146b4357c08d:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Ftest%2F01165%2Ftest_13%2Frmt%2Freplicas%2F1&part=20250728_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.6.10636.altinitytest (altinity build)) '. (RECEIVED_ERROR_FROM_REMOTE_IO_SERVER), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.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 const&, int&&, String const&, unsigned long&&, String const&) @ 0x000000000feda8d9 4. /build/src/IO/HTTPCommon.cpp:104: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x000000000feda6e2 5. /build/src/IO/HTTPCommon.cpp:93: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x000000000feda537 6. /build/src/IO/ReadWriteBufferFromHTTP.cpp:277: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x000000001184a4c4 7. /build/src/IO/ReadWriteBufferFromHTTP.cpp:285: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x000000001184a615 8. /build/src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x000000001184ae59 9. /build/src/IO/ReadWriteBufferFromHTTP.cpp:472: void std::__function::__policy_invoker::__call_impl[abi:se190107]>(std::__function::__policy_storage const*) @ 0x000000001184cedd 10. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001184858b 11. /build/src/IO/ReadWriteBufferFromHTTP.cpp:465: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x000000001184bf0b 12. /build/src/IO/ReadBuffer.h:60: DB::ReadBuffer::next() @ 0x000000000a148c7b 13. /build/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) @ 0x0000000011849fb2 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]>&)>&, 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&) @ 0x0000000011841980 15. /build/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) @ 0x000000001621208e 16. /build/src/Storages/StorageReplicatedMergeTree.cpp:5228: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl[abi:se190107] const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000015f9a5fe 17. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000015ed8bfd 18. /build/src/Storages/StorageReplicatedMergeTree.cpp:2514: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x0000000015ec9aab 19. /build/src/Storages/StorageReplicatedMergeTree.cpp:2349: DB::StorageReplicatedMergeTree::executeLogEntry(DB::ReplicatedMergeTreeLogEntry&) @ 0x0000000015eba91b 20. /build/src/Storages/StorageReplicatedMergeTree.cpp:3876: bool std::__function::__policy_invoker&)>::__call_impl[abi:se190107])::$_1, bool (std::shared_ptr&)>>(std::__function::__policy_storage const*, std::shared_ptr&) @ 0x0000000015f9837e 21. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000165d6fc3 22. /build/src/Storages/StorageReplicatedMergeTree.cpp:3872: DB::StorageReplicatedMergeTree::processQueueEntry(std::shared_ptr) @ 0x0000000015efc18a 23. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001624c1b2 24. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000162f9c70 25. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x00000000162fa55a 26. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc6653 27. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000000fccc4c3 28. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc3d92 29. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fcca080 30. ? @ 0x00007fbc6213eac3 31. ? @ 0x00007fbc621d0850 (version 25.3.6.10636.altinitytest (altinity build)) 2025.07.28 11:59:04.265252 [ 3977 ] {} test_13.rmt2 (7f9b740d-015c-470e-8cc6-8ba33be0dc63): auto DB::StorageReplicatedMergeTree::processQueueEntry(ReplicatedMergeTreeQueue::SelectedEntryPtr)::(anonymous class)::operator()(LogEntryPtr &) const: Code: 86. DB::HTTPException: Received error from remote server http://146b4357c08d:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Ftest%2F01165%2Ftest_13%2Frmt%2Freplicas%2F1&part=20250728_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.6.10636.altinitytest (altinity build)) '. (RECEIVED_ERROR_FROM_REMOTE_IO_SERVER), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.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 const&, int&&, String const&, unsigned long&&, String const&) @ 0x000000000feda8d9 4. /build/src/IO/HTTPCommon.cpp:104: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x000000000feda6e2 5. /build/src/IO/HTTPCommon.cpp:93: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x000000000feda537 6. /build/src/IO/ReadWriteBufferFromHTTP.cpp:277: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x000000001184a4c4 7. /build/src/IO/ReadWriteBufferFromHTTP.cpp:285: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x000000001184a615 8. /build/src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x000000001184ae59 9. /build/src/IO/ReadWriteBufferFromHTTP.cpp:472: void std::__function::__policy_invoker::__call_impl[abi:se190107]>(std::__function::__policy_storage const*) @ 0x000000001184cedd 10. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001184858b 11. /build/src/IO/ReadWriteBufferFromHTTP.cpp:465: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x000000001184bf0b 12. /build/src/IO/ReadBuffer.h:60: DB::ReadBuffer::next() @ 0x000000000a148c7b 13. /build/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) @ 0x0000000011849fb2 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]>&)>&, 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&) @ 0x0000000011841980 15. /build/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) @ 0x000000001621208e 16. /build/src/Storages/StorageReplicatedMergeTree.cpp:5228: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl[abi:se190107] const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000015f9a5fe 17. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000015ed8bfd 18. /build/src/Storages/StorageReplicatedMergeTree.cpp:2514: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x0000000015ec9aab 19. /build/src/Storages/StorageReplicatedMergeTree.cpp:2349: DB::StorageReplicatedMergeTree::executeLogEntry(DB::ReplicatedMergeTreeLogEntry&) @ 0x0000000015eba91b 20. /build/src/Storages/StorageReplicatedMergeTree.cpp:3876: bool std::__function::__policy_invoker&)>::__call_impl[abi:se190107])::$_1, bool (std::shared_ptr&)>>(std::__function::__policy_storage const*, std::shared_ptr&) @ 0x0000000015f9837e 21. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000165d6fc3 22. /build/src/Storages/StorageReplicatedMergeTree.cpp:3872: DB::StorageReplicatedMergeTree::processQueueEntry(std::shared_ptr) @ 0x0000000015efc18a 23. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001624c1b2 24. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000162f9c70 25. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x00000000162fa55a 26. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc6653 27. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000000fccc4c3 28. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc3d92 29. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fcca080 30. ? @ 0x00007fbc6213eac3 31. ? @ 0x00007fbc621d0850 (version 25.3.6.10636.altinitytest (altinity build)) 2025.07.28 11:59:05.318303 [ 3970 ] {} test_13.rmt2 (7f9b740d-015c-470e-8cc6-8ba33be0dc63): auto DB::StorageReplicatedMergeTree::processQueueEntry(ReplicatedMergeTreeQueue::SelectedEntryPtr)::(anonymous class)::operator()(LogEntryPtr &) const: Code: 86. DB::HTTPException: Received error from remote server http://146b4357c08d:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Ftest%2F01165%2Ftest_13%2Frmt%2Freplicas%2F1&part=20250728_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.6.10636.altinitytest (altinity build)) '. (RECEIVED_ERROR_FROM_REMOTE_IO_SERVER), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.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 const&, int&&, String const&, unsigned long&&, String const&) @ 0x000000000feda8d9 4. /build/src/IO/HTTPCommon.cpp:104: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x000000000feda6e2 5. /build/src/IO/HTTPCommon.cpp:93: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x000000000feda537 6. /build/src/IO/ReadWriteBufferFromHTTP.cpp:277: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x000000001184a4c4 7. /build/src/IO/ReadWriteBufferFromHTTP.cpp:285: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x000000001184a615 8. /build/src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x000000001184ae59 9. /build/src/IO/ReadWriteBufferFromHTTP.cpp:472: void std::__function::__policy_invoker::__call_impl[abi:se190107]>(std::__function::__policy_storage const*) @ 0x000000001184cedd 10. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001184858b 11. /build/src/IO/ReadWriteBufferFromHTTP.cpp:465: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x000000001184bf0b 12. /build/src/IO/ReadBuffer.h:60: DB::ReadBuffer::next() @ 0x000000000a148c7b 13. /build/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) @ 0x0000000011849fb2 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]>&)>&, 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&) @ 0x0000000011841980 15. /build/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) @ 0x000000001621208e 16. /build/src/Storages/StorageReplicatedMergeTree.cpp:5228: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl[abi:se190107] const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000015f9a5fe 17. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000015ed8bfd 18. /build/src/Storages/StorageReplicatedMergeTree.cpp:2514: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x0000000015ec9aab 19. /build/src/Storages/StorageReplicatedMergeTree.cpp:2349: DB::StorageReplicatedMergeTree::executeLogEntry(DB::ReplicatedMergeTreeLogEntry&) @ 0x0000000015eba91b 20. /build/src/Storages/StorageReplicatedMergeTree.cpp:3876: bool std::__function::__policy_invoker&)>::__call_impl[abi:se190107])::$_1, bool (std::shared_ptr&)>>(std::__function::__policy_storage const*, std::shared_ptr&) @ 0x0000000015f9837e 21. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000165d6fc3 22. /build/src/Storages/StorageReplicatedMergeTree.cpp:3872: DB::StorageReplicatedMergeTree::processQueueEntry(std::shared_ptr) @ 0x0000000015efc18a 23. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001624c1b2 24. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000162f9c70 25. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x00000000162fa55a 26. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc6653 27. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000000fccc4c3 28. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc3d92 29. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fcca080 30. ? @ 0x00007fbc6213eac3 31. ? @ 0x00007fbc621d0850 (version 25.3.6.10636.altinitytest (altinity build)) 2025.07.28 11:59:05.952550 [ 7630 ] {9fb740a8-6c68-4f3f-a275-95ac4243d050} 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.6.10636.altinitytest (altinity build)) (from [::1]:51204) (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. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String const&) @ 0x000000000a68756b 4. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5172: DB::QueryAnalyzer::resolveJoin(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&) @ 0x0000000014048477 5. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5361: DB::QueryAnalyzer::resolveQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&) @ 0x00000000140452d6 6. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5597: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000140136f0 7. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000140127f9 8. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000014011fce 9. /build/src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000001406ce8a 10. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000014973b42 11. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000001497268d 12. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000014974d24 13. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001492924b 14. /build/src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88641 15. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 16. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 17. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 18. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 19. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 20. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 21. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 22. ? @ 0x00007fbc6213eac3 23. ? @ 0x00007fbc621d0850 2025.07.28 11:59:05.956285 [ 7630 ] {} 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. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String const&) @ 0x000000000a68756b 4. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5172: DB::QueryAnalyzer::resolveJoin(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&) @ 0x0000000014048477 5. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5361: DB::QueryAnalyzer::resolveQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&) @ 0x00000000140452d6 6. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5597: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000140136f0 7. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000140127f9 8. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000014011fce 9. /build/src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000001406ce8a 10. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000014973b42 11. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000001497268d 12. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000014974d24 13. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001492924b 14. /build/src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88641 15. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 16. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 17. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 18. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 19. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 20. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 21. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 22. ? @ 0x00007fbc6213eac3 23. ? @ 0x00007fbc621d0850 2025.07.28 11:59:05.984777 [ 3965 ] {} test_13.rmt2 (7f9b740d-015c-470e-8cc6-8ba33be0dc63): auto DB::StorageReplicatedMergeTree::processQueueEntry(ReplicatedMergeTreeQueue::SelectedEntryPtr)::(anonymous class)::operator()(LogEntryPtr &) const: Code: 86. DB::HTTPException: Received error from remote server http://146b4357c08d:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Ftest%2F01165%2Ftest_13%2Frmt%2Freplicas%2F1&part=20250728_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.6.10636.altinitytest (altinity build)) '. (RECEIVED_ERROR_FROM_REMOTE_IO_SERVER), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.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 const&, int&&, String const&, unsigned long&&, String const&) @ 0x000000000feda8d9 4. /build/src/IO/HTTPCommon.cpp:104: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x000000000feda6e2 5. /build/src/IO/HTTPCommon.cpp:93: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x000000000feda537 6. /build/src/IO/ReadWriteBufferFromHTTP.cpp:277: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x000000001184a4c4 7. /build/src/IO/ReadWriteBufferFromHTTP.cpp:285: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x000000001184a615 8. /build/src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x000000001184ae59 9. /build/src/IO/ReadWriteBufferFromHTTP.cpp:472: void std::__function::__policy_invoker::__call_impl[abi:se190107]>(std::__function::__policy_storage const*) @ 0x000000001184cedd 10. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001184858b 11. /build/src/IO/ReadWriteBufferFromHTTP.cpp:465: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x000000001184bf0b 12. /build/src/IO/ReadBuffer.h:60: DB::ReadBuffer::next() @ 0x000000000a148c7b 13. /build/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) @ 0x0000000011849fb2 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]>&)>&, 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&) @ 0x0000000011841980 15. /build/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) @ 0x000000001621208e 16. /build/src/Storages/StorageReplicatedMergeTree.cpp:5228: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl[abi:se190107] const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000015f9a5fe 17. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000015ed8bfd 18. /build/src/Storages/StorageReplicatedMergeTree.cpp:2514: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x0000000015ec9aab 19. /build/src/Storages/StorageReplicatedMergeTree.cpp:2349: DB::StorageReplicatedMergeTree::executeLogEntry(DB::ReplicatedMergeTreeLogEntry&) @ 0x0000000015eba91b 20. /build/src/Storages/StorageReplicatedMergeTree.cpp:3876: bool std::__function::__policy_invoker&)>::__call_impl[abi:se190107])::$_1, bool (std::shared_ptr&)>>(std::__function::__policy_storage const*, std::shared_ptr&) @ 0x0000000015f9837e 21. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000165d6fc3 22. /build/src/Storages/StorageReplicatedMergeTree.cpp:3872: DB::StorageReplicatedMergeTree::processQueueEntry(std::shared_ptr) @ 0x0000000015efc18a 23. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001624c1b2 24. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000162f9c70 25. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x00000000162fa55a 26. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc6653 27. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000000fccc4c3 28. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc3d92 29. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fcca080 30. ? @ 0x00007fbc6213eac3 31. ? @ 0x00007fbc621d0850 (version 25.3.6.10636.altinitytest (altinity build)) 2025.07.28 11:59:06.344601 [ 3969 ] {} test_13.rmt2 (7f9b740d-015c-470e-8cc6-8ba33be0dc63): auto DB::StorageReplicatedMergeTree::processQueueEntry(ReplicatedMergeTreeQueue::SelectedEntryPtr)::(anonymous class)::operator()(LogEntryPtr &) const: Code: 86. DB::HTTPException: Received error from remote server http://146b4357c08d:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Ftest%2F01165%2Ftest_13%2Frmt%2Freplicas%2F1&part=20250728_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.6.10636.altinitytest (altinity build)) '. (RECEIVED_ERROR_FROM_REMOTE_IO_SERVER), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.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 const&, int&&, String const&, unsigned long&&, String const&) @ 0x000000000feda8d9 4. /build/src/IO/HTTPCommon.cpp:104: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x000000000feda6e2 5. /build/src/IO/HTTPCommon.cpp:93: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x000000000feda537 6. /build/src/IO/ReadWriteBufferFromHTTP.cpp:277: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x000000001184a4c4 7. /build/src/IO/ReadWriteBufferFromHTTP.cpp:285: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x000000001184a615 8. /build/src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x000000001184ae59 9. /build/src/IO/ReadWriteBufferFromHTTP.cpp:472: void std::__function::__policy_invoker::__call_impl[abi:se190107]>(std::__function::__policy_storage const*) @ 0x000000001184cedd 10. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001184858b 11. /build/src/IO/ReadWriteBufferFromHTTP.cpp:465: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x000000001184bf0b 12. /build/src/IO/ReadBuffer.h:60: DB::ReadBuffer::next() @ 0x000000000a148c7b 13. /build/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) @ 0x0000000011849fb2 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]>&)>&, 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&) @ 0x0000000011841980 15. /build/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) @ 0x000000001621208e 16. /build/src/Storages/StorageReplicatedMergeTree.cpp:5228: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl[abi:se190107] const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000015f9a5fe 17. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000015ed8bfd 18. /build/src/Storages/StorageReplicatedMergeTree.cpp:2514: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x0000000015ec9aab 19. /build/src/Storages/StorageReplicatedMergeTree.cpp:2349: DB::StorageReplicatedMergeTree::executeLogEntry(DB::ReplicatedMergeTreeLogEntry&) @ 0x0000000015eba91b 20. /build/src/Storages/StorageReplicatedMergeTree.cpp:3876: bool std::__function::__policy_invoker&)>::__call_impl[abi:se190107])::$_1, bool (std::shared_ptr&)>>(std::__function::__policy_storage const*, std::shared_ptr&) @ 0x0000000015f9837e 21. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000165d6fc3 22. /build/src/Storages/StorageReplicatedMergeTree.cpp:3872: DB::StorageReplicatedMergeTree::processQueueEntry(std::shared_ptr) @ 0x0000000015efc18a 23. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001624c1b2 24. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000162f9c70 25. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x00000000162fa55a 26. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc6653 27. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000000fccc4c3 28. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc3d92 29. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fcca080 30. ? @ 0x00007fbc6213eac3 31. ? @ 0x00007fbc621d0850 (version 25.3.6.10636.altinitytest (altinity build)) 2025.07.28 11:59:06.852312 [ 3961 ] {} test_13.rmt2 (7f9b740d-015c-470e-8cc6-8ba33be0dc63): auto DB::StorageReplicatedMergeTree::processQueueEntry(ReplicatedMergeTreeQueue::SelectedEntryPtr)::(anonymous class)::operator()(LogEntryPtr &) const: Code: 86. DB::HTTPException: Received error from remote server http://146b4357c08d:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Ftest%2F01165%2Ftest_13%2Frmt%2Freplicas%2F1&part=20250728_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.6.10636.altinitytest (altinity build)) '. (RECEIVED_ERROR_FROM_REMOTE_IO_SERVER), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.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 const&, int&&, String const&, unsigned long&&, String const&) @ 0x000000000feda8d9 4. /build/src/IO/HTTPCommon.cpp:104: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x000000000feda6e2 5. /build/src/IO/HTTPCommon.cpp:93: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x000000000feda537 6. /build/src/IO/ReadWriteBufferFromHTTP.cpp:277: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x000000001184a4c4 7. /build/src/IO/ReadWriteBufferFromHTTP.cpp:285: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x000000001184a615 8. /build/src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x000000001184ae59 9. /build/src/IO/ReadWriteBufferFromHTTP.cpp:472: void std::__function::__policy_invoker::__call_impl[abi:se190107]>(std::__function::__policy_storage const*) @ 0x000000001184cedd 10. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001184858b 11. /build/src/IO/ReadWriteBufferFromHTTP.cpp:465: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x000000001184bf0b 12. /build/src/IO/ReadBuffer.h:60: DB::ReadBuffer::next() @ 0x000000000a148c7b 13. /build/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) @ 0x0000000011849fb2 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]>&)>&, 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&) @ 0x0000000011841980 15. /build/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) @ 0x000000001621208e 16. /build/src/Storages/StorageReplicatedMergeTree.cpp:5228: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl[abi:se190107] const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000015f9a5fe 17. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000015ed8bfd 18. /build/src/Storages/StorageReplicatedMergeTree.cpp:2514: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x0000000015ec9aab 19. /build/src/Storages/StorageReplicatedMergeTree.cpp:2349: DB::StorageReplicatedMergeTree::executeLogEntry(DB::ReplicatedMergeTreeLogEntry&) @ 0x0000000015eba91b 20. /build/src/Storages/StorageReplicatedMergeTree.cpp:3876: bool std::__function::__policy_invoker&)>::__call_impl[abi:se190107])::$_1, bool (std::shared_ptr&)>>(std::__function::__policy_storage const*, std::shared_ptr&) @ 0x0000000015f9837e 21. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000165d6fc3 22. /build/src/Storages/StorageReplicatedMergeTree.cpp:3872: DB::StorageReplicatedMergeTree::processQueueEntry(std::shared_ptr) @ 0x0000000015efc18a 23. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001624c1b2 24. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000162f9c70 25. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x00000000162fa55a 26. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc6653 27. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000000fccc4c3 28. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc3d92 29. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fcca080 30. ? @ 0x00007fbc6213eac3 31. ? @ 0x00007fbc621d0850 (version 25.3.6.10636.altinitytest (altinity build)) 2025.07.28 11:59:07.001059 [ 3974 ] {} test_13.rmt2 (7f9b740d-015c-470e-8cc6-8ba33be0dc63): auto DB::StorageReplicatedMergeTree::processQueueEntry(ReplicatedMergeTreeQueue::SelectedEntryPtr)::(anonymous class)::operator()(LogEntryPtr &) const: Code: 86. DB::HTTPException: Received error from remote server http://146b4357c08d:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Ftest%2F01165%2Ftest_13%2Frmt%2Freplicas%2F1&part=20250728_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.6.10636.altinitytest (altinity build)) '. (RECEIVED_ERROR_FROM_REMOTE_IO_SERVER), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.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 const&, int&&, String const&, unsigned long&&, String const&) @ 0x000000000feda8d9 4. /build/src/IO/HTTPCommon.cpp:104: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x000000000feda6e2 5. /build/src/IO/HTTPCommon.cpp:93: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x000000000feda537 6. /build/src/IO/ReadWriteBufferFromHTTP.cpp:277: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x000000001184a4c4 7. /build/src/IO/ReadWriteBufferFromHTTP.cpp:285: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x000000001184a615 8. /build/src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x000000001184ae59 9. /build/src/IO/ReadWriteBufferFromHTTP.cpp:472: void std::__function::__policy_invoker::__call_impl[abi:se190107]>(std::__function::__policy_storage const*) @ 0x000000001184cedd 10. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001184858b 11. /build/src/IO/ReadWriteBufferFromHTTP.cpp:465: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x000000001184bf0b 12. /build/src/IO/ReadBuffer.h:60: DB::ReadBuffer::next() @ 0x000000000a148c7b 13. /build/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) @ 0x0000000011849fb2 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]>&)>&, 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&) @ 0x0000000011841980 15. /build/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) @ 0x000000001621208e 16. /build/src/Storages/StorageReplicatedMergeTree.cpp:5228: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl[abi:se190107] const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000015f9a5fe 17. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000015ed8bfd 18. /build/src/Storages/StorageReplicatedMergeTree.cpp:2514: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x0000000015ec9aab 19. /build/src/Storages/StorageReplicatedMergeTree.cpp:2349: DB::StorageReplicatedMergeTree::executeLogEntry(DB::ReplicatedMergeTreeLogEntry&) @ 0x0000000015eba91b 20. /build/src/Storages/StorageReplicatedMergeTree.cpp:3876: bool std::__function::__policy_invoker&)>::__call_impl[abi:se190107])::$_1, bool (std::shared_ptr&)>>(std::__function::__policy_storage const*, std::shared_ptr&) @ 0x0000000015f9837e 21. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000165d6fc3 22. /build/src/Storages/StorageReplicatedMergeTree.cpp:3872: DB::StorageReplicatedMergeTree::processQueueEntry(std::shared_ptr) @ 0x0000000015efc18a 23. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001624c1b2 24. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000162f9c70 25. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x00000000162fa55a 26. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc6653 27. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000000fccc4c3 28. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc3d92 29. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fcca080 30. ? @ 0x00007fbc6213eac3 31. ? @ 0x00007fbc621d0850 (version 25.3.6.10636.altinitytest (altinity build)) 2025.07.28 11:59:07.580920 [ 3964 ] {} test_13.rmt2 (7f9b740d-015c-470e-8cc6-8ba33be0dc63): auto DB::StorageReplicatedMergeTree::processQueueEntry(ReplicatedMergeTreeQueue::SelectedEntryPtr)::(anonymous class)::operator()(LogEntryPtr &) const: Code: 86. DB::HTTPException: Received error from remote server http://146b4357c08d:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Ftest%2F01165%2Ftest_13%2Frmt%2Freplicas%2F1&part=20250728_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.6.10636.altinitytest (altinity build)) '. (RECEIVED_ERROR_FROM_REMOTE_IO_SERVER), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.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 const&, int&&, String const&, unsigned long&&, String const&) @ 0x000000000feda8d9 4. /build/src/IO/HTTPCommon.cpp:104: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x000000000feda6e2 5. /build/src/IO/HTTPCommon.cpp:93: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x000000000feda537 6. /build/src/IO/ReadWriteBufferFromHTTP.cpp:277: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x000000001184a4c4 7. /build/src/IO/ReadWriteBufferFromHTTP.cpp:285: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x000000001184a615 8. /build/src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x000000001184ae59 9. /build/src/IO/ReadWriteBufferFromHTTP.cpp:472: void std::__function::__policy_invoker::__call_impl[abi:se190107]>(std::__function::__policy_storage const*) @ 0x000000001184cedd 10. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001184858b 11. /build/src/IO/ReadWriteBufferFromHTTP.cpp:465: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x000000001184bf0b 12. /build/src/IO/ReadBuffer.h:60: DB::ReadBuffer::next() @ 0x000000000a148c7b 13. /build/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) @ 0x0000000011849fb2 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]>&)>&, 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&) @ 0x0000000011841980 15. /build/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) @ 0x000000001621208e 16. /build/src/Storages/StorageReplicatedMergeTree.cpp:5228: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl[abi:se190107] const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000015f9a5fe 17. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000015ed8bfd 18. /build/src/Storages/StorageReplicatedMergeTree.cpp:2514: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x0000000015ec9aab 19. /build/src/Storages/StorageReplicatedMergeTree.cpp:2349: DB::StorageReplicatedMergeTree::executeLogEntry(DB::ReplicatedMergeTreeLogEntry&) @ 0x0000000015eba91b 20. /build/src/Storages/StorageReplicatedMergeTree.cpp:3876: bool std::__function::__policy_invoker&)>::__call_impl[abi:se190107])::$_1, bool (std::shared_ptr&)>>(std::__function::__policy_storage const*, std::shared_ptr&) @ 0x0000000015f9837e 21. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000165d6fc3 22. /build/src/Storages/StorageReplicatedMergeTree.cpp:3872: DB::StorageReplicatedMergeTree::processQueueEntry(std::shared_ptr) @ 0x0000000015efc18a 23. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001624c1b2 24. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000162f9c70 25. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x00000000162fa55a 26. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc6653 27. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000000fccc4c3 28. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc3d92 29. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fcca080 30. ? @ 0x00007fbc6213eac3 31. ? @ 0x00007fbc621d0850 (version 25.3.6.10636.altinitytest (altinity build)) 2025.07.28 11:59:08.338794 [ 4900 ] {44506ff2-ad8a-44f8-aa16-6f600d6bd064} executeQuery: Code: 48. DB::Exception: Alter of type 'ADD_COLUMN' is not supported by storage SystemNumbers. (NOT_IMPLEMENTED) (version 25.3.6.10636.altinitytest (altinity build)) (from [::1]:51290) (comment: 01461_alter_table_function.sql) (query 10, line 17) (in query: ALTER TABLE table_from_numbers ADD COLUMN col UInt8;), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, DB::AlterCommand::Type const&, String&&) @ 0x00000000134653eb 4. /build/src/Storages/IStorage.cpp:243: DB::IStorage::checkAlterIsPossible(DB::AlterCommands const&, std::shared_ptr) const @ 0x0000000015d1f6fc 5. /build/src/Interpreters/InterpreterAlterQuery.cpp:215: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x00000000148deab3 6. /build/src/Interpreters/InterpreterAlterQuery.cpp:77: DB::InterpreterAlterQuery::execute() @ 0x00000000148dcb0d 7. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88dc9 8. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 9. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 10. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 11. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 12. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 13. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 14. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 15. ? @ 0x00007fbc6213eac3 16. ? @ 0x00007fbc621d0850 2025.07.28 11:59:08.342144 [ 4900 ] {} TCPHandler: Code: 48. DB::Exception: Alter of type 'ADD_COLUMN' is not supported by storage SystemNumbers. (NOT_IMPLEMENTED), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, DB::AlterCommand::Type const&, String&&) @ 0x00000000134653eb 4. /build/src/Storages/IStorage.cpp:243: DB::IStorage::checkAlterIsPossible(DB::AlterCommands const&, std::shared_ptr) const @ 0x0000000015d1f6fc 5. /build/src/Interpreters/InterpreterAlterQuery.cpp:215: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x00000000148deab3 6. /build/src/Interpreters/InterpreterAlterQuery.cpp:77: DB::InterpreterAlterQuery::execute() @ 0x00000000148dcb0d 7. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88dc9 8. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 9. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 10. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 11. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 12. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 13. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 14. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 15. ? @ 0x00007fbc6213eac3 16. ? @ 0x00007fbc621d0850 2025.07.28 11:59:08.401165 [ 3974 ] {} test_13.rmt2 (7f9b740d-015c-470e-8cc6-8ba33be0dc63): auto DB::StorageReplicatedMergeTree::processQueueEntry(ReplicatedMergeTreeQueue::SelectedEntryPtr)::(anonymous class)::operator()(LogEntryPtr &) const: Code: 86. DB::HTTPException: Received error from remote server http://146b4357c08d:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Ftest%2F01165%2Ftest_13%2Frmt%2Freplicas%2F1&part=20250728_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.6.10636.altinitytest (altinity build)) '. (RECEIVED_ERROR_FROM_REMOTE_IO_SERVER), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.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 const&, int&&, String const&, unsigned long&&, String const&) @ 0x000000000feda8d9 4. /build/src/IO/HTTPCommon.cpp:104: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x000000000feda6e2 5. /build/src/IO/HTTPCommon.cpp:93: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x000000000feda537 6. /build/src/IO/ReadWriteBufferFromHTTP.cpp:277: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x000000001184a4c4 7. /build/src/IO/ReadWriteBufferFromHTTP.cpp:285: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x000000001184a615 8. /build/src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x000000001184ae59 9. /build/src/IO/ReadWriteBufferFromHTTP.cpp:472: void std::__function::__policy_invoker::__call_impl[abi:se190107]>(std::__function::__policy_storage const*) @ 0x000000001184cedd 10. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001184858b 11. /build/src/IO/ReadWriteBufferFromHTTP.cpp:465: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x000000001184bf0b 12. /build/src/IO/ReadBuffer.h:60: DB::ReadBuffer::next() @ 0x000000000a148c7b 13. /build/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) @ 0x0000000011849fb2 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]>&)>&, 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&) @ 0x0000000011841980 15. /build/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) @ 0x000000001621208e 16. /build/src/Storages/StorageReplicatedMergeTree.cpp:5228: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl[abi:se190107] const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000015f9a5fe 17. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000015ed8bfd 18. /build/src/Storages/StorageReplicatedMergeTree.cpp:2514: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x0000000015ec9aab 19. /build/src/Storages/StorageReplicatedMergeTree.cpp:2349: DB::StorageReplicatedMergeTree::executeLogEntry(DB::ReplicatedMergeTreeLogEntry&) @ 0x0000000015eba91b 20. /build/src/Storages/StorageReplicatedMergeTree.cpp:3876: bool std::__function::__policy_invoker&)>::__call_impl[abi:se190107])::$_1, bool (std::shared_ptr&)>>(std::__function::__policy_storage const*, std::shared_ptr&) @ 0x0000000015f9837e 21. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000165d6fc3 22. /build/src/Storages/StorageReplicatedMergeTree.cpp:3872: DB::StorageReplicatedMergeTree::processQueueEntry(std::shared_ptr) @ 0x0000000015efc18a 23. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001624c1b2 24. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000162f9c70 25. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x00000000162fa55a 26. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc6653 27. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000000fccc4c3 28. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc3d92 29. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fcca080 30. ? @ 0x00007fbc6213eac3 31. ? @ 0x00007fbc621d0850 (version 25.3.6.10636.altinitytest (altinity build)) 2025.07.28 11:59:09.162403 [ 3963 ] {} test_13.rmt2 (7f9b740d-015c-470e-8cc6-8ba33be0dc63): auto DB::StorageReplicatedMergeTree::processQueueEntry(ReplicatedMergeTreeQueue::SelectedEntryPtr)::(anonymous class)::operator()(LogEntryPtr &) const: Code: 86. DB::HTTPException: Received error from remote server http://146b4357c08d:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Ftest%2F01165%2Ftest_13%2Frmt%2Freplicas%2F1&part=20250728_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.6.10636.altinitytest (altinity build)) '. (RECEIVED_ERROR_FROM_REMOTE_IO_SERVER), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.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 const&, int&&, String const&, unsigned long&&, String const&) @ 0x000000000feda8d9 4. /build/src/IO/HTTPCommon.cpp:104: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x000000000feda6e2 5. /build/src/IO/HTTPCommon.cpp:93: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x000000000feda537 6. /build/src/IO/ReadWriteBufferFromHTTP.cpp:277: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x000000001184a4c4 7. /build/src/IO/ReadWriteBufferFromHTTP.cpp:285: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x000000001184a615 8. /build/src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x000000001184ae59 9. /build/src/IO/ReadWriteBufferFromHTTP.cpp:472: void std::__function::__policy_invoker::__call_impl[abi:se190107]>(std::__function::__policy_storage const*) @ 0x000000001184cedd 10. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001184858b 11. /build/src/IO/ReadWriteBufferFromHTTP.cpp:465: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x000000001184bf0b 12. /build/src/IO/ReadBuffer.h:60: DB::ReadBuffer::next() @ 0x000000000a148c7b 13. /build/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) @ 0x0000000011849fb2 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]>&)>&, 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&) @ 0x0000000011841980 15. /build/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) @ 0x000000001621208e 16. /build/src/Storages/StorageReplicatedMergeTree.cpp:5228: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl[abi:se190107] const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000015f9a5fe 17. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000015ed8bfd 18. /build/src/Storages/StorageReplicatedMergeTree.cpp:2514: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x0000000015ec9aab 19. /build/src/Storages/StorageReplicatedMergeTree.cpp:2349: DB::StorageReplicatedMergeTree::executeLogEntry(DB::ReplicatedMergeTreeLogEntry&) @ 0x0000000015eba91b 20. /build/src/Storages/StorageReplicatedMergeTree.cpp:3876: bool std::__function::__policy_invoker&)>::__call_impl[abi:se190107])::$_1, bool (std::shared_ptr&)>>(std::__function::__policy_storage const*, std::shared_ptr&) @ 0x0000000015f9837e 21. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000165d6fc3 22. /build/src/Storages/StorageReplicatedMergeTree.cpp:3872: DB::StorageReplicatedMergeTree::processQueueEntry(std::shared_ptr) @ 0x0000000015efc18a 23. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001624c1b2 24. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000162f9c70 25. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x00000000162fa55a 26. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc6653 27. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000000fccc4c3 28. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc3d92 29. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fcca080 30. ? @ 0x00007fbc6213eac3 31. ? @ 0x00007fbc621d0850 (version 25.3.6.10636.altinitytest (altinity build)) 2025.07.28 11:59:09.693166 [ 3971 ] {} test_13.rmt2 (7f9b740d-015c-470e-8cc6-8ba33be0dc63): auto DB::StorageReplicatedMergeTree::processQueueEntry(ReplicatedMergeTreeQueue::SelectedEntryPtr)::(anonymous class)::operator()(LogEntryPtr &) const: Code: 86. DB::HTTPException: Received error from remote server http://146b4357c08d:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Ftest%2F01165%2Ftest_13%2Frmt%2Freplicas%2F1&part=20250728_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.6.10636.altinitytest (altinity build)) '. (RECEIVED_ERROR_FROM_REMOTE_IO_SERVER), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.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 const&, int&&, String const&, unsigned long&&, String const&) @ 0x000000000feda8d9 4. /build/src/IO/HTTPCommon.cpp:104: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x000000000feda6e2 5. /build/src/IO/HTTPCommon.cpp:93: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x000000000feda537 6. /build/src/IO/ReadWriteBufferFromHTTP.cpp:277: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x000000001184a4c4 7. /build/src/IO/ReadWriteBufferFromHTTP.cpp:285: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x000000001184a615 8. /build/src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x000000001184ae59 9. /build/src/IO/ReadWriteBufferFromHTTP.cpp:472: void std::__function::__policy_invoker::__call_impl[abi:se190107]>(std::__function::__policy_storage const*) @ 0x000000001184cedd 10. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001184858b 11. /build/src/IO/ReadWriteBufferFromHTTP.cpp:465: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x000000001184bf0b 12. /build/src/IO/ReadBuffer.h:60: DB::ReadBuffer::next() @ 0x000000000a148c7b 13. /build/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) @ 0x0000000011849fb2 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]>&)>&, 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&) @ 0x0000000011841980 15. /build/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) @ 0x000000001621208e 16. /build/src/Storages/StorageReplicatedMergeTree.cpp:5228: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl[abi:se190107] const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000015f9a5fe 17. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000015ed8bfd 18. /build/src/Storages/StorageReplicatedMergeTree.cpp:2514: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x0000000015ec9aab 19. /build/src/Storages/StorageReplicatedMergeTree.cpp:2349: DB::StorageReplicatedMergeTree::executeLogEntry(DB::ReplicatedMergeTreeLogEntry&) @ 0x0000000015eba91b 20. /build/src/Storages/StorageReplicatedMergeTree.cpp:3876: bool std::__function::__policy_invoker&)>::__call_impl[abi:se190107])::$_1, bool (std::shared_ptr&)>>(std::__function::__policy_storage const*, std::shared_ptr&) @ 0x0000000015f9837e 21. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000165d6fc3 22. /build/src/Storages/StorageReplicatedMergeTree.cpp:3872: DB::StorageReplicatedMergeTree::processQueueEntry(std::shared_ptr) @ 0x0000000015efc18a 23. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001624c1b2 24. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000162f9c70 25. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x00000000162fa55a 26. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc6653 27. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000000fccc4c3 28. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc3d92 29. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fcca080 30. ? @ 0x00007fbc6213eac3 31. ? @ 0x00007fbc621d0850 (version 25.3.6.10636.altinitytest (altinity build)) 2025.07.28 11:59:09.788644 [ 17255 ] {4f79673b-ee2b-4b9a-8e14-157e403c332b} executeQuery: Code: 70. DB::Exception: Cannot convert type UInt32 to Variant(String, UInt64). Conversion to Variant allowed only for types from this Variant: In scope SELECT CAST(CAST('42', 'UInt32'), 'Variant(String, UInt64)'). (CANNOT_CONVERT_TYPE) (version 25.3.6.10636.altinitytest (altinity build)) (from [::1]:51346) (comment: 02942_variant_cast.sql) (query 4, line 5) (in query: select 42::UInt32::Variant(String, UInt64);), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000a06a8eb 4. /build/src/Functions/FunctionsConversion.h:5168: DB::detail::FunctionCast::createColumnToVariantWrapper(std::shared_ptr const&, DB::DataTypeVariant const&) const @ 0x0000000012de42a2 5. /build/src/Functions/FunctionsConversion.h:5271: DB::detail::FunctionCast::createVariantWrapper(std::shared_ptr const&, std::shared_ptr const&) const @ 0x0000000012ddd79f 6. /build/src/Functions/FunctionsConversion.h:5713: DB::detail::FunctionCast::prepareUnpackDictionaries(std::shared_ptr const&, std::shared_ptr const&) const @ 0x0000000012ddc4c4 7. /build/src/Functions/FunctionsConversion.h:3444: DB::detail::FunctionCast::prepare(std::vector> const&) const @ 0x0000000012ddbeb0 8. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3558: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000014033b60 9. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3838: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000014019a9e 10. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3980: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000014018e31 11. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:4304: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000014042fa7 12. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5605: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000014013749 13. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000140127f9 14. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000014011fce 15. /build/src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000001406ce8a 16. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000014973b42 17. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000001497268d 18. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000014974d24 19. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001492924b 20. /build/src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88641 21. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 22. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 23. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 24. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 25. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 26. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 27. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 28. ? @ 0x00007fbc6213eac3 29. ? @ 0x00007fbc621d0850 2025.07.28 11:59:09.792200 [ 17255 ] {} TCPHandler: Code: 70. DB::Exception: Cannot convert type UInt32 to Variant(String, UInt64). Conversion to Variant allowed only for types from this Variant: In scope SELECT CAST(CAST('42', 'UInt32'), 'Variant(String, UInt64)'). (CANNOT_CONVERT_TYPE), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000a06a8eb 4. /build/src/Functions/FunctionsConversion.h:5168: DB::detail::FunctionCast::createColumnToVariantWrapper(std::shared_ptr const&, DB::DataTypeVariant const&) const @ 0x0000000012de42a2 5. /build/src/Functions/FunctionsConversion.h:5271: DB::detail::FunctionCast::createVariantWrapper(std::shared_ptr const&, std::shared_ptr const&) const @ 0x0000000012ddd79f 6. /build/src/Functions/FunctionsConversion.h:5713: DB::detail::FunctionCast::prepareUnpackDictionaries(std::shared_ptr const&, std::shared_ptr const&) const @ 0x0000000012ddc4c4 7. /build/src/Functions/FunctionsConversion.h:3444: DB::detail::FunctionCast::prepare(std::vector> const&) const @ 0x0000000012ddbeb0 8. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3558: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000014033b60 9. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3838: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000014019a9e 10. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3980: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000014018e31 11. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:4304: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000014042fa7 12. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5605: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000014013749 13. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000140127f9 14. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000014011fce 15. /build/src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000001406ce8a 16. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000014973b42 17. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000001497268d 18. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000014974d24 19. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001492924b 20. /build/src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88641 21. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 22. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 23. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 24. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 25. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 26. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 27. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 28. ? @ 0x00007fbc6213eac3 29. ? @ 0x00007fbc621d0850 2025.07.28 11:59:09.944939 [ 17255 ] {014ac421-1323-4156-9b1e-6422a4271bb8} executeQuery: Code: 70. DB::Exception: Cannot convert type DateTime to Variant(String, UInt64). Conversion to Variant allowed only for types from this Variant: In scope SELECT CAST(now(), 'Variant(String, UInt64)'). (CANNOT_CONVERT_TYPE) (version 25.3.6.10636.altinitytest (altinity build)) (from [::1]:51346) (comment: 02942_variant_cast.sql) (query 5, line 6) (in query: select now()::Variant(String, UInt64);), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000a06a8eb 4. /build/src/Functions/FunctionsConversion.h:5168: DB::detail::FunctionCast::createColumnToVariantWrapper(std::shared_ptr const&, DB::DataTypeVariant const&) const @ 0x0000000012de42a2 5. /build/src/Functions/FunctionsConversion.h:5271: DB::detail::FunctionCast::createVariantWrapper(std::shared_ptr const&, std::shared_ptr const&) const @ 0x0000000012ddd79f 6. /build/src/Functions/FunctionsConversion.h:5713: DB::detail::FunctionCast::prepareUnpackDictionaries(std::shared_ptr const&, std::shared_ptr const&) const @ 0x0000000012ddc4c4 7. /build/src/Functions/FunctionsConversion.h:3444: DB::detail::FunctionCast::prepare(std::vector> const&) const @ 0x0000000012ddbeb0 8. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3558: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000014033b60 9. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3838: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000014019a9e 10. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3980: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000014018e31 11. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:4304: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000014042fa7 12. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5605: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000014013749 13. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000140127f9 14. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000014011fce 15. /build/src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000001406ce8a 16. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000014973b42 17. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000001497268d 18. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000014974d24 19. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001492924b 20. /build/src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88641 21. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 22. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 23. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 24. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 25. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 26. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 27. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 28. ? @ 0x00007fbc6213eac3 29. ? @ 0x00007fbc621d0850 2025.07.28 11:59:09.953444 [ 17255 ] {} TCPHandler: Code: 70. DB::Exception: Cannot convert type DateTime to Variant(String, UInt64). Conversion to Variant allowed only for types from this Variant: In scope SELECT CAST(now(), 'Variant(String, UInt64)'). (CANNOT_CONVERT_TYPE), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000a06a8eb 4. /build/src/Functions/FunctionsConversion.h:5168: DB::detail::FunctionCast::createColumnToVariantWrapper(std::shared_ptr const&, DB::DataTypeVariant const&) const @ 0x0000000012de42a2 5. /build/src/Functions/FunctionsConversion.h:5271: DB::detail::FunctionCast::createVariantWrapper(std::shared_ptr const&, std::shared_ptr const&) const @ 0x0000000012ddd79f 6. /build/src/Functions/FunctionsConversion.h:5713: DB::detail::FunctionCast::prepareUnpackDictionaries(std::shared_ptr const&, std::shared_ptr const&) const @ 0x0000000012ddc4c4 7. /build/src/Functions/FunctionsConversion.h:3444: DB::detail::FunctionCast::prepare(std::vector> const&) const @ 0x0000000012ddbeb0 8. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3558: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000014033b60 9. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3838: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000014019a9e 10. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3980: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000014018e31 11. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:4304: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000014042fa7 12. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5605: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000014013749 13. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000140127f9 14. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000014011fce 15. /build/src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000001406ce8a 16. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000014973b42 17. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000001497268d 18. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000014974d24 19. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001492924b 20. /build/src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88641 21. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 22. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 23. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 24. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 25. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 26. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 27. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 28. ? @ 0x00007fbc6213eac3 29. ? @ 0x00007fbc621d0850 2025.07.28 11:59:10.755782 [ 3966 ] {} test_13.rmt2 (7f9b740d-015c-470e-8cc6-8ba33be0dc63): auto DB::StorageReplicatedMergeTree::processQueueEntry(ReplicatedMergeTreeQueue::SelectedEntryPtr)::(anonymous class)::operator()(LogEntryPtr &) const: Code: 86. DB::HTTPException: Received error from remote server http://146b4357c08d:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Ftest%2F01165%2Ftest_13%2Frmt%2Freplicas%2F1&part=20250728_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.6.10636.altinitytest (altinity build)) '. (RECEIVED_ERROR_FROM_REMOTE_IO_SERVER), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.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 const&, int&&, String const&, unsigned long&&, String const&) @ 0x000000000feda8d9 4. /build/src/IO/HTTPCommon.cpp:104: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x000000000feda6e2 5. /build/src/IO/HTTPCommon.cpp:93: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x000000000feda537 6. /build/src/IO/ReadWriteBufferFromHTTP.cpp:277: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x000000001184a4c4 7. /build/src/IO/ReadWriteBufferFromHTTP.cpp:285: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x000000001184a615 8. /build/src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x000000001184ae59 9. /build/src/IO/ReadWriteBufferFromHTTP.cpp:472: void std::__function::__policy_invoker::__call_impl[abi:se190107]>(std::__function::__policy_storage const*) @ 0x000000001184cedd 10. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001184858b 11. /build/src/IO/ReadWriteBufferFromHTTP.cpp:465: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x000000001184bf0b 12. /build/src/IO/ReadBuffer.h:60: DB::ReadBuffer::next() @ 0x000000000a148c7b 13. /build/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) @ 0x0000000011849fb2 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]>&)>&, 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&) @ 0x0000000011841980 15. /build/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) @ 0x000000001621208e 16. /build/src/Storages/StorageReplicatedMergeTree.cpp:5228: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl[abi:se190107] const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000015f9a5fe 17. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000015ed8bfd 18. /build/src/Storages/StorageReplicatedMergeTree.cpp:2514: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x0000000015ec9aab 19. /build/src/Storages/StorageReplicatedMergeTree.cpp:2349: DB::StorageReplicatedMergeTree::executeLogEntry(DB::ReplicatedMergeTreeLogEntry&) @ 0x0000000015eba91b 20. /build/src/Storages/StorageReplicatedMergeTree.cpp:3876: bool std::__function::__policy_invoker&)>::__call_impl[abi:se190107])::$_1, bool (std::shared_ptr&)>>(std::__function::__policy_storage const*, std::shared_ptr&) @ 0x0000000015f9837e 21. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000165d6fc3 22. /build/src/Storages/StorageReplicatedMergeTree.cpp:3872: DB::StorageReplicatedMergeTree::processQueueEntry(std::shared_ptr) @ 0x0000000015efc18a 23. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001624c1b2 24. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000162f9c70 25. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x00000000162fa55a 26. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc6653 27. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000000fccc4c3 28. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc3d92 29. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fcca080 30. ? @ 0x00007fbc6213eac3 31. ? @ 0x00007fbc621d0850 (version 25.3.6.10636.altinitytest (altinity build)) 2025.07.28 11:59:11.176221 [ 17255 ] {cba14f59-24bc-45fb-867a-89e0cf5180a2} executeQuery: Code: 6. DB::Exception: Cannot parse string 'str' as UInt64: syntax error at begin of string. Note: there are toUInt64OrZero and toUInt64OrNull functions, which returns zero/NULL instead of throwing exception.: In scope SELECT CAST(CAST('str', 'Variant(String, UInt64)'), 'UInt64'). (CANNOT_PARSE_TEXT) (version 25.3.6.10636.altinitytest (altinity build)) (from [::1]:51346) (comment: 02942_variant_cast.sql) (query 15, line 17) (in query: select 'str'::Variant(String, UInt64)::UInt64;), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Functions/FunctionsConversion.h:796: DB::detail::throwExceptionForIncompletelyParsedValue(DB::ReadBuffer&, DB::IDataType const&) @ 0x000000000a150a93 4. /build/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*) @ 0x0000000012ff668a 5. /build/src/Functions/FunctionsConversion.h:1580: COW::immutable_ptr DB::detail::ConvertImpl, DB::detail::NameToUInt64, (DB::FormatSettings::DateTimeOverflowBehavior)0>::execute(std::vector> const&, std::shared_ptr const&, unsigned long, DB::detail::BehaviourOnErrorFromString, void*) @ 0x0000000012ff637e 6. /build/src/Functions/FunctionsConversion.h:2472: 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&&) @ 0x0000000012f9da04 7. /build/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 @ 0x0000000012fb254e 8. /build/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 @ 0x0000000012fb1d7a 9. /build/src/Functions/IFunctionAdaptors.cpp:10: DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000012d995fa 10. /build/src/Functions/IFunction.cpp:353: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d93b52 11. /build/src/Functions/IFunction.cpp:420: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d95059 12. /build/src/Functions/IFunction.cpp:498: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d95c72 13. /build/src/Functions/IFunction.cpp:513: DB::IFunctionBase::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d96059 14. /build/src/Functions/FunctionsConversion.h:3487: COW::immutable_ptr std::__function::__policy_invoker::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)>::__call_impl[abi:se190107], 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) @ 0x0000000012e00996 15. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000012dec734 16. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: COW::immutable_ptr std::__function::__policy_invoker::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)>::__call_impl[abi:se190107] 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) @ 0x0000000012dec3ec 17. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000012ddcb1b 18. /build/src/Functions/IFunction.h:57: DB::IExecutableFunction::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000a08134a 19. /build/src/Functions/IFunction.cpp:351: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d93b02 20. /build/src/Functions/IFunction.cpp:177: DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d93698 21. /build/src/Functions/IFunction.cpp:343: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d93aad 22. /build/src/Functions/IFunction.cpp:424: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d94e1b 23. /build/src/Functions/IFunction.cpp:498: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d95c72 24. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3567: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000014034494 25. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3838: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000014019a9e 26. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3980: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000014018e31 27. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:4304: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000014042fa7 28. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5605: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000014013749 29. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000140127f9 30. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000014011fce 31. /build/src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000001406ce8a 2025.07.28 11:59:11.184597 [ 17255 ] {} TCPHandler: Code: 6. DB::Exception: Cannot parse string 'str' as UInt64: syntax error at begin of string. Note: there are toUInt64OrZero and toUInt64OrNull functions, which returns zero/NULL instead of throwing exception.: In scope SELECT CAST(CAST('str', 'Variant(String, UInt64)'), 'UInt64'). (CANNOT_PARSE_TEXT), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Functions/FunctionsConversion.h:796: DB::detail::throwExceptionForIncompletelyParsedValue(DB::ReadBuffer&, DB::IDataType const&) @ 0x000000000a150a93 4. /build/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*) @ 0x0000000012ff668a 5. /build/src/Functions/FunctionsConversion.h:1580: COW::immutable_ptr DB::detail::ConvertImpl, DB::detail::NameToUInt64, (DB::FormatSettings::DateTimeOverflowBehavior)0>::execute(std::vector> const&, std::shared_ptr const&, unsigned long, DB::detail::BehaviourOnErrorFromString, void*) @ 0x0000000012ff637e 6. /build/src/Functions/FunctionsConversion.h:2472: 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&&) @ 0x0000000012f9da04 7. /build/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 @ 0x0000000012fb254e 8. /build/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 @ 0x0000000012fb1d7a 9. /build/src/Functions/IFunctionAdaptors.cpp:10: DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000012d995fa 10. /build/src/Functions/IFunction.cpp:353: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d93b52 11. /build/src/Functions/IFunction.cpp:420: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d95059 12. /build/src/Functions/IFunction.cpp:498: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d95c72 13. /build/src/Functions/IFunction.cpp:513: DB::IFunctionBase::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d96059 14. /build/src/Functions/FunctionsConversion.h:3487: COW::immutable_ptr std::__function::__policy_invoker::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)>::__call_impl[abi:se190107], 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) @ 0x0000000012e00996 15. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000012dec734 16. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: COW::immutable_ptr std::__function::__policy_invoker::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)>::__call_impl[abi:se190107] 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) @ 0x0000000012dec3ec 17. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000012ddcb1b 18. /build/src/Functions/IFunction.h:57: DB::IExecutableFunction::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000a08134a 19. /build/src/Functions/IFunction.cpp:351: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d93b02 20. /build/src/Functions/IFunction.cpp:177: DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d93698 21. /build/src/Functions/IFunction.cpp:343: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d93aad 22. /build/src/Functions/IFunction.cpp:424: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d94e1b 23. /build/src/Functions/IFunction.cpp:498: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d95c72 24. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3567: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000014034494 25. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3838: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000014019a9e 26. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3980: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000014018e31 27. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:4304: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000014042fa7 28. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5605: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000014013749 29. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000140127f9 30. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000014011fce 31. /build/src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000001406ce8a 2025.07.28 11:59:11.480433 [ 17255 ] {ee5ee797-05d1-4388-99b6-eac0622818e1} executeQuery: 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(multiIf(equals(__table1.number, 1_UInt8), _CAST(NULL_Variant(String, UInt64), 'Variant(String, UInt64)'_String), equals(__table1.number, 2_UInt8), _CAST('Hello'_Variant(String, UInt64), 'Variant(String, UInt64)'_String), CAST(__table1.number, 'Variant(String, UInt64)'_String)) :: 5, 'UInt64'_String :: 6) -> CAST(multiIf(equals(__table1.number, 1_UInt8), _CAST(NULL_Variant(String, UInt64), 'Variant(String, UInt64)'_String), equals(__table1.number, 2_UInt8), _CAST('Hello'_Variant(String, UInt64), 'Variant(String, UInt64)'_String), CAST(__table1.number, 'Variant(String, UInt64)'_String)), 'UInt64'_String) UInt64 : 3'. (CANNOT_PARSE_TEXT) (version 25.3.6.10636.altinitytest (altinity build)) (from [::1]:51346) (comment: 02942_variant_cast.sql) (query 17, line 19) (in query: select CAST(multiIf(number == 1, NULL::Variant(String, UInt64), number == 2, 'Hello'::Variant(String, UInt64), number::Variant(String, UInt64)), 'UInt64') from numbers(6);), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Functions/FunctionsConversion.h:796: DB::detail::throwExceptionForIncompletelyParsedValue(DB::ReadBuffer&, DB::IDataType const&) @ 0x000000000a150a93 4. /build/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*) @ 0x0000000012ff668a 5. /build/src/Functions/FunctionsConversion.h:1580: COW::immutable_ptr DB::detail::ConvertImpl, DB::detail::NameToUInt64, (DB::FormatSettings::DateTimeOverflowBehavior)0>::execute(std::vector> const&, std::shared_ptr const&, unsigned long, DB::detail::BehaviourOnErrorFromString, void*) @ 0x0000000012ff637e 6. /build/src/Functions/FunctionsConversion.h:2472: 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&&) @ 0x0000000012f9da04 7. /build/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 @ 0x0000000012fb254e 8. /build/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 @ 0x0000000012fb1d7a 9. /build/src/Functions/IFunctionAdaptors.cpp:10: DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000012d995fa 10. /build/src/Functions/IFunction.cpp:353: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d93b52 11. /build/src/Functions/IFunction.cpp:420: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d95059 12. /build/src/Functions/IFunction.cpp:498: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d95c72 13. /build/src/Functions/IFunction.cpp:513: DB::IFunctionBase::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d96059 14. /build/src/Functions/FunctionsConversion.h:3487: COW::immutable_ptr std::__function::__policy_invoker::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)>::__call_impl[abi:se190107], 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) @ 0x0000000012e00996 15. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000012dec734 16. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: COW::immutable_ptr std::__function::__policy_invoker::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)>::__call_impl[abi:se190107] 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) @ 0x0000000012dec3ec 17. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000012ddcb1b 18. /build/src/Functions/IFunction.cpp:353: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d93b52 19. /build/src/Functions/IFunction.cpp:424: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d94e1b 20. /build/src/Functions/IFunction.cpp:498: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d95c72 21. /build/src/Interpreters/ExpressionActions.cpp:636: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x00000000145176f3 22. /build/src/Processors/Transforms/ExpressionTransform.cpp:25: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x0000000016c0b34c 23. /build/src/Processors/ISimpleTransform.h:33: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000011a9a453 24. /build/src/Processors/ISimpleTransform.cpp:89: DB::ISimpleTransform::work() @ 0x000000001699fca0 25. /build/src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x00000000169bd00f 26. /build/src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x00000000169b2105 27. /build/src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeSingleThread(unsigned long) @ 0x00000000169b23be 28. /build/src/Processors/Executors/PipelineExecutor.cpp:454: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x00000000169b0be7 29. /build/src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x00000000169b03f4 30. /build/src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:se190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169bfeab 31. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc3d92 2025.07.28 11:59:11.484897 [ 17255 ] {} TCPHandler: 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(multiIf(equals(__table1.number, 1_UInt8), _CAST(NULL_Variant(String, UInt64), 'Variant(String, UInt64)'_String), equals(__table1.number, 2_UInt8), _CAST('Hello'_Variant(String, UInt64), 'Variant(String, UInt64)'_String), CAST(__table1.number, 'Variant(String, UInt64)'_String)) :: 5, 'UInt64'_String :: 6) -> CAST(multiIf(equals(__table1.number, 1_UInt8), _CAST(NULL_Variant(String, UInt64), 'Variant(String, UInt64)'_String), equals(__table1.number, 2_UInt8), _CAST('Hello'_Variant(String, UInt64), 'Variant(String, UInt64)'_String), CAST(__table1.number, 'Variant(String, UInt64)'_String)), 'UInt64'_String) UInt64 : 3'. (CANNOT_PARSE_TEXT), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Functions/FunctionsConversion.h:796: DB::detail::throwExceptionForIncompletelyParsedValue(DB::ReadBuffer&, DB::IDataType const&) @ 0x000000000a150a93 4. /build/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*) @ 0x0000000012ff668a 5. /build/src/Functions/FunctionsConversion.h:1580: COW::immutable_ptr DB::detail::ConvertImpl, DB::detail::NameToUInt64, (DB::FormatSettings::DateTimeOverflowBehavior)0>::execute(std::vector> const&, std::shared_ptr const&, unsigned long, DB::detail::BehaviourOnErrorFromString, void*) @ 0x0000000012ff637e 6. /build/src/Functions/FunctionsConversion.h:2472: 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&&) @ 0x0000000012f9da04 7. /build/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 @ 0x0000000012fb254e 8. /build/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 @ 0x0000000012fb1d7a 9. /build/src/Functions/IFunctionAdaptors.cpp:10: DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000012d995fa 10. /build/src/Functions/IFunction.cpp:353: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d93b52 11. /build/src/Functions/IFunction.cpp:420: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d95059 12. /build/src/Functions/IFunction.cpp:498: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d95c72 13. /build/src/Functions/IFunction.cpp:513: DB::IFunctionBase::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d96059 14. /build/src/Functions/FunctionsConversion.h:3487: COW::immutable_ptr std::__function::__policy_invoker::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)>::__call_impl[abi:se190107], 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) @ 0x0000000012e00996 15. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000012dec734 16. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: COW::immutable_ptr std::__function::__policy_invoker::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)>::__call_impl[abi:se190107] 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) @ 0x0000000012dec3ec 17. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000012ddcb1b 18. /build/src/Functions/IFunction.cpp:353: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d93b52 19. /build/src/Functions/IFunction.cpp:424: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d94e1b 20. /build/src/Functions/IFunction.cpp:498: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d95c72 21. /build/src/Interpreters/ExpressionActions.cpp:636: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x00000000145176f3 22. /build/src/Processors/Transforms/ExpressionTransform.cpp:25: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x0000000016c0b34c 23. /build/src/Processors/ISimpleTransform.h:33: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000011a9a453 24. /build/src/Processors/ISimpleTransform.cpp:89: DB::ISimpleTransform::work() @ 0x000000001699fca0 25. /build/src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x00000000169bd00f 26. /build/src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x00000000169b2105 27. /build/src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeSingleThread(unsigned long) @ 0x00000000169b23be 28. /build/src/Processors/Executors/PipelineExecutor.cpp:454: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x00000000169b0be7 29. /build/src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x00000000169b03f4 30. /build/src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:se190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169bfeab 31. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc3d92 Job's origin stack trace: 0. /build/src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000000fc33b84 1. /build/src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000000fcc2ea7 2. /build/src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fcc535c 3. /build/src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000000fcc584d 4. /build/src/Common/ThreadPool.h:279: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x00000000169bf193 5. /build/src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x00000000169bf518 6. /build/src/Server/TCPHandler.cpp:1237: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x00000000168f1525 7. /build/src/Server/TCPHandler.cpp:678: DB::TCPHandler::runImpl() @ 0x00000000168e68e5 8. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 9. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 10. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 11. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 12. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 13. ? @ 0x00007fbc6213eac3 14. ? @ 0x00007fbc621d0850 2025.07.28 11:59:11.501102 [ 3976 ] {} test_13.rmt2 (7f9b740d-015c-470e-8cc6-8ba33be0dc63): auto DB::StorageReplicatedMergeTree::processQueueEntry(ReplicatedMergeTreeQueue::SelectedEntryPtr)::(anonymous class)::operator()(LogEntryPtr &) const: Code: 86. DB::HTTPException: Received error from remote server http://146b4357c08d:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Ftest%2F01165%2Ftest_13%2Frmt%2Freplicas%2F1&part=20250728_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.6.10636.altinitytest (altinity build)) '. (RECEIVED_ERROR_FROM_REMOTE_IO_SERVER), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.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 const&, int&&, String const&, unsigned long&&, String const&) @ 0x000000000feda8d9 4. /build/src/IO/HTTPCommon.cpp:104: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x000000000feda6e2 5. /build/src/IO/HTTPCommon.cpp:93: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x000000000feda537 6. /build/src/IO/ReadWriteBufferFromHTTP.cpp:277: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x000000001184a4c4 7. /build/src/IO/ReadWriteBufferFromHTTP.cpp:285: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x000000001184a615 8. /build/src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x000000001184ae59 9. /build/src/IO/ReadWriteBufferFromHTTP.cpp:472: void std::__function::__policy_invoker::__call_impl[abi:se190107]>(std::__function::__policy_storage const*) @ 0x000000001184cedd 10. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001184858b 11. /build/src/IO/ReadWriteBufferFromHTTP.cpp:465: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x000000001184bf0b 12. /build/src/IO/ReadBuffer.h:60: DB::ReadBuffer::next() @ 0x000000000a148c7b 13. /build/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) @ 0x0000000011849fb2 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]>&)>&, 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&) @ 0x0000000011841980 15. /build/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) @ 0x000000001621208e 16. /build/src/Storages/StorageReplicatedMergeTree.cpp:5228: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl[abi:se190107] const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000015f9a5fe 17. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000015ed8bfd 18. /build/src/Storages/StorageReplicatedMergeTree.cpp:2514: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x0000000015ec9aab 19. /build/src/Storages/StorageReplicatedMergeTree.cpp:2349: DB::StorageReplicatedMergeTree::executeLogEntry(DB::ReplicatedMergeTreeLogEntry&) @ 0x0000000015eba91b 20. /build/src/Storages/StorageReplicatedMergeTree.cpp:3876: bool std::__function::__policy_invoker&)>::__call_impl[abi:se190107])::$_1, bool (std::shared_ptr&)>>(std::__function::__policy_storage const*, std::shared_ptr&) @ 0x0000000015f9837e 21. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000165d6fc3 22. /build/src/Storages/StorageReplicatedMergeTree.cpp:3872: DB::StorageReplicatedMergeTree::processQueueEntry(std::shared_ptr) @ 0x0000000015efc18a 23. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001624c1b2 24. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000162f9c70 25. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x00000000162fa55a 26. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc6653 27. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000000fccc4c3 28. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc3d92 29. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fcca080 30. ? @ 0x00007fbc6213eac3 31. ? @ 0x00007fbc621d0850 (version 25.3.6.10636.altinitytest (altinity build)) 2025.07.28 11:59:11.618939 [ 17255 ] {d41305ee-6ad1-45fa-a664-06ece89a30b0} executeQuery: Code: 70. DB::Exception: Cannot convert type Variant(String, UInt64) to Variant(Array(UInt64), String). Conversion between Variant types is allowed only when new Variant type is an extension of an initial one: In scope SELECT CAST(CAST('str', 'Variant(String, UInt64)'), 'Variant(String, Array(UInt64))'). (CANNOT_CONVERT_TYPE) (version 25.3.6.10636.altinitytest (altinity build)) (from [::1]:51346) (comment: 02942_variant_cast.sql) (query 19, line 23) (in query: select 'str'::Variant(String, UInt64)::Variant(String, Array(UInt64));), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000a06a8eb 4. /build/src/Functions/FunctionsConversion.h:4988: DB::detail::FunctionCast::createVariantToVariantWrapper(DB::DataTypeVariant const&, DB::DataTypeVariant const&) const @ 0x0000000012de4ef4 5. /build/src/Functions/FunctionsConversion.h:5266: DB::detail::FunctionCast::createVariantWrapper(std::shared_ptr const&, std::shared_ptr const&) const @ 0x0000000012ddd77e 6. /build/src/Functions/FunctionsConversion.h:5713: DB::detail::FunctionCast::prepareUnpackDictionaries(std::shared_ptr const&, std::shared_ptr const&) const @ 0x0000000012ddc4c4 7. /build/src/Functions/FunctionsConversion.h:3444: DB::detail::FunctionCast::prepare(std::vector> const&) const @ 0x0000000012ddbeb0 8. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3558: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000014033b60 9. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3838: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000014019a9e 10. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3980: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000014018e31 11. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:4304: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000014042fa7 12. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5605: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000014013749 13. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000140127f9 14. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000014011fce 15. /build/src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000001406ce8a 16. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000014973b42 17. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000001497268d 18. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000014974d24 19. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001492924b 20. /build/src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88641 21. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 22. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 23. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 24. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 25. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 26. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 27. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 28. ? @ 0x00007fbc6213eac3 29. ? @ 0x00007fbc621d0850 2025.07.28 11:59:11.625786 [ 17255 ] {} TCPHandler: Code: 70. DB::Exception: Cannot convert type Variant(String, UInt64) to Variant(Array(UInt64), String). Conversion between Variant types is allowed only when new Variant type is an extension of an initial one: In scope SELECT CAST(CAST('str', 'Variant(String, UInt64)'), 'Variant(String, Array(UInt64))'). (CANNOT_CONVERT_TYPE), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000a06a8eb 4. /build/src/Functions/FunctionsConversion.h:4988: DB::detail::FunctionCast::createVariantToVariantWrapper(DB::DataTypeVariant const&, DB::DataTypeVariant const&) const @ 0x0000000012de4ef4 5. /build/src/Functions/FunctionsConversion.h:5266: DB::detail::FunctionCast::createVariantWrapper(std::shared_ptr const&, std::shared_ptr const&) const @ 0x0000000012ddd77e 6. /build/src/Functions/FunctionsConversion.h:5713: DB::detail::FunctionCast::prepareUnpackDictionaries(std::shared_ptr const&, std::shared_ptr const&) const @ 0x0000000012ddc4c4 7. /build/src/Functions/FunctionsConversion.h:3444: DB::detail::FunctionCast::prepare(std::vector> const&) const @ 0x0000000012ddbeb0 8. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3558: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000014033b60 9. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3838: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000014019a9e 10. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3980: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000014018e31 11. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:4304: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000014042fa7 12. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5605: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000014013749 13. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000140127f9 14. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000014011fce 15. /build/src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000001406ce8a 16. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000014973b42 17. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000001497268d 18. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000014974d24 19. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001492924b 20. /build/src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88641 21. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 22. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 23. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 24. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 25. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 26. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 27. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 28. ? @ 0x00007fbc6213eac3 29. ? @ 0x00007fbc621d0850 2025.07.28 11:59:12.090173 [ 11826 ] {d9755d39-e545-40c7-b237-edbaca4f1c8f} executeQuery: Code: 47. DB::Exception: Unknown expression or function identifier `number` in scope SELECT arrayFilter(x -> notEmpty(concat(x, 'hello')), ['']) FROM system.one ARRAY JOIN [0] AS elem, arrayMap(x -> concat(x, ignore(ignore(toLowCardinality('03147_parquet_memory_tracking.parquet'), 37, 37, toUInt128(37), 37, 37, toLowCardinality(37), 37), 8, ignore(ignore(1., 36, 8, 8)), *), 'hello'), ['']) AS unused WHERE NOT ignore(elem) GROUP BY sum(ignore(ignore(ignore(1., 1, 36, 8, 8), ignore(52, 37, 37, '03147_parquet_memory_tracking.parquet', 37, 37, toUInt256(37), 37, 37, toNullable(37), 37, 37), 1., 1, 36, 8, 8), emptyArrayToSingle(arrayMap(x -> toString(x), arrayMap(x -> nullIf(x, 2), arrayJoin([[1]])))))) IGNORE NULLS, modulo(toLowCardinality('03147_parquet_memory_tracking.parquet'), number, toLowCardinality(3)). (UNKNOWN_IDENTIFIER) (version 25.3.6.10636.altinitytest (altinity build)) (from [::1]:51324) (comment: 02374_analyzer_array_join.sql) (query 32, line 70) (in query: SELECT arrayFilter(x -> notEmpty(concat(x, 'hello')), ['']) FROM system.one ARRAY JOIN [0] AS elem, arrayMap(x -> concat(x, ignore(ignore(toLowCardinality('03147_parquet_memory_tracking.parquet'), 37, 37, toUInt128(37), 37, 37, toLowCardinality(37), 37), 8, ignore(ignore(1., 36, 8, 8)), *), 'hello'), ['']) AS unused WHERE NOT ignore(elem) GROUP BY sum(ignore(ignore(ignore(1., 1, 36, 8, 8), ignore(52, 37, 37, '03147_parquet_memory_tracking.parquet', 37, 37, toUInt256(37), 37, 37, toNullable(37), 37, 37), 1., 1, 36, 8, 8), emptyArrayToSingle(arrayMap(x -> toString(x), arrayMap(x -> nullIf(x, 2), arrayJoin([[1]])))))) IGNORE NULLS, modulo(toLowCardinality('03147_parquet_memory_tracking.parquet'), number, toLowCardinality(3));), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.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&&) @ 0x000000001404b3b9 4. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3771: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000001401b849 5. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3980: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000014018e31 6. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:2925: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000001402fcbd 7. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3838: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000014019a9e 8. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3980: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000014018e31 9. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:4228: DB::QueryAnalyzer::resolveGroupByNode(DB::QueryNode&, DB::IdentifierResolveScope&) @ 0x0000000014041ea4 10. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5633: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000140139da 11. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000140127f9 12. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000014011fce 13. /build/src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000001406ce8a 14. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000014973b42 15. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000001497268d 16. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000014974d24 17. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001492924b 18. /build/src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88641 19. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 20. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 21. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 22. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 23. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 24. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 25. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 26. ? @ 0x00007fbc6213eac3 27. ? @ 0x00007fbc621d0850 2025.07.28 11:59:12.124060 [ 11826 ] {} TCPHandler: Code: 47. DB::Exception: Unknown expression or function identifier `number` in scope SELECT arrayFilter(x -> notEmpty(concat(x, 'hello')), ['']) FROM system.one ARRAY JOIN [0] AS elem, arrayMap(x -> concat(x, ignore(ignore(toLowCardinality('03147_parquet_memory_tracking.parquet'), 37, 37, toUInt128(37), 37, 37, toLowCardinality(37), 37), 8, ignore(ignore(1., 36, 8, 8)), *), 'hello'), ['']) AS unused WHERE NOT ignore(elem) GROUP BY sum(ignore(ignore(ignore(1., 1, 36, 8, 8), ignore(52, 37, 37, '03147_parquet_memory_tracking.parquet', 37, 37, toUInt256(37), 37, 37, toNullable(37), 37, 37), 1., 1, 36, 8, 8), emptyArrayToSingle(arrayMap(x -> toString(x), arrayMap(x -> nullIf(x, 2), arrayJoin([[1]])))))) IGNORE NULLS, modulo(toLowCardinality('03147_parquet_memory_tracking.parquet'), number, toLowCardinality(3)). (UNKNOWN_IDENTIFIER), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.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&&) @ 0x000000001404b3b9 4. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3771: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000001401b849 5. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3980: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000014018e31 6. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:2925: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000001402fcbd 7. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3838: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000014019a9e 8. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3980: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000014018e31 9. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:4228: DB::QueryAnalyzer::resolveGroupByNode(DB::QueryNode&, DB::IdentifierResolveScope&) @ 0x0000000014041ea4 10. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5633: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000140139da 11. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000140127f9 12. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000014011fce 13. /build/src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000001406ce8a 14. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000014973b42 15. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000001497268d 16. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000014974d24 17. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001492924b 18. /build/src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88641 19. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 20. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 21. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 22. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 23. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 24. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 25. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 26. ? @ 0x00007fbc6213eac3 27. ? @ 0x00007fbc621d0850 2025.07.28 11:59:12.204895 [ 3970 ] {} test_13.rmt2 (7f9b740d-015c-470e-8cc6-8ba33be0dc63): auto DB::StorageReplicatedMergeTree::processQueueEntry(ReplicatedMergeTreeQueue::SelectedEntryPtr)::(anonymous class)::operator()(LogEntryPtr &) const: Code: 86. DB::HTTPException: Received error from remote server http://146b4357c08d:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Ftest%2F01165%2Ftest_13%2Frmt%2Freplicas%2F1&part=20250728_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.6.10636.altinitytest (altinity build)) '. (RECEIVED_ERROR_FROM_REMOTE_IO_SERVER), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.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 const&, int&&, String const&, unsigned long&&, String const&) @ 0x000000000feda8d9 4. /build/src/IO/HTTPCommon.cpp:104: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x000000000feda6e2 5. /build/src/IO/HTTPCommon.cpp:93: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x000000000feda537 6. /build/src/IO/ReadWriteBufferFromHTTP.cpp:277: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x000000001184a4c4 7. /build/src/IO/ReadWriteBufferFromHTTP.cpp:285: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x000000001184a615 8. /build/src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x000000001184ae59 9. /build/src/IO/ReadWriteBufferFromHTTP.cpp:472: void std::__function::__policy_invoker::__call_impl[abi:se190107]>(std::__function::__policy_storage const*) @ 0x000000001184cedd 10. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001184858b 11. /build/src/IO/ReadWriteBufferFromHTTP.cpp:465: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x000000001184bf0b 12. /build/src/IO/ReadBuffer.h:60: DB::ReadBuffer::next() @ 0x000000000a148c7b 13. /build/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) @ 0x0000000011849fb2 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]>&)>&, 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&) @ 0x0000000011841980 15. /build/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) @ 0x000000001621208e 16. /build/src/Storages/StorageReplicatedMergeTree.cpp:5228: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl[abi:se190107] const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000015f9a5fe 17. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000015ed8bfd 18. /build/src/Storages/StorageReplicatedMergeTree.cpp:2514: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x0000000015ec9aab 19. /build/src/Storages/StorageReplicatedMergeTree.cpp:2349: DB::StorageReplicatedMergeTree::executeLogEntry(DB::ReplicatedMergeTreeLogEntry&) @ 0x0000000015eba91b 20. /build/src/Storages/StorageReplicatedMergeTree.cpp:3876: bool std::__function::__policy_invoker&)>::__call_impl[abi:se190107])::$_1, bool (std::shared_ptr&)>>(std::__function::__policy_storage const*, std::shared_ptr&) @ 0x0000000015f9837e 21. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000165d6fc3 22. /build/src/Storages/StorageReplicatedMergeTree.cpp:3872: DB::StorageReplicatedMergeTree::processQueueEntry(std::shared_ptr) @ 0x0000000015efc18a 23. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001624c1b2 24. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000162f9c70 25. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x00000000162fa55a 26. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc6653 27. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000000fccc4c3 28. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc3d92 29. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fcca080 30. ? @ 0x00007fbc6213eac3 31. ? @ 0x00007fbc621d0850 (version 25.3.6.10636.altinitytest (altinity build)) 2025.07.28 11:59:12.890785 [ 3968 ] {} test_13.rmt2 (7f9b740d-015c-470e-8cc6-8ba33be0dc63): auto DB::StorageReplicatedMergeTree::processQueueEntry(ReplicatedMergeTreeQueue::SelectedEntryPtr)::(anonymous class)::operator()(LogEntryPtr &) const: Code: 86. DB::HTTPException: Received error from remote server http://146b4357c08d:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Ftest%2F01165%2Ftest_13%2Frmt%2Freplicas%2F1&part=20250728_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.6.10636.altinitytest (altinity build)) '. (RECEIVED_ERROR_FROM_REMOTE_IO_SERVER), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.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 const&, int&&, String const&, unsigned long&&, String const&) @ 0x000000000feda8d9 4. /build/src/IO/HTTPCommon.cpp:104: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x000000000feda6e2 5. /build/src/IO/HTTPCommon.cpp:93: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x000000000feda537 6. /build/src/IO/ReadWriteBufferFromHTTP.cpp:277: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x000000001184a4c4 7. /build/src/IO/ReadWriteBufferFromHTTP.cpp:285: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x000000001184a615 8. /build/src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x000000001184ae59 9. /build/src/IO/ReadWriteBufferFromHTTP.cpp:472: void std::__function::__policy_invoker::__call_impl[abi:se190107]>(std::__function::__policy_storage const*) @ 0x000000001184cedd 10. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001184858b 11. /build/src/IO/ReadWriteBufferFromHTTP.cpp:465: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x000000001184bf0b 12. /build/src/IO/ReadBuffer.h:60: DB::ReadBuffer::next() @ 0x000000000a148c7b 13. /build/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) @ 0x0000000011849fb2 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]>&)>&, 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&) @ 0x0000000011841980 15. /build/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) @ 0x000000001621208e 16. /build/src/Storages/StorageReplicatedMergeTree.cpp:5228: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl[abi:se190107] const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000015f9a5fe 17. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000015ed8bfd 18. /build/src/Storages/StorageReplicatedMergeTree.cpp:2514: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x0000000015ec9aab 19. /build/src/Storages/StorageReplicatedMergeTree.cpp:2349: DB::StorageReplicatedMergeTree::executeLogEntry(DB::ReplicatedMergeTreeLogEntry&) @ 0x0000000015eba91b 20. /build/src/Storages/StorageReplicatedMergeTree.cpp:3876: bool std::__function::__policy_invoker&)>::__call_impl[abi:se190107])::$_1, bool (std::shared_ptr&)>>(std::__function::__policy_storage const*, std::shared_ptr&) @ 0x0000000015f9837e 21. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000165d6fc3 22. /build/src/Storages/StorageReplicatedMergeTree.cpp:3872: DB::StorageReplicatedMergeTree::processQueueEntry(std::shared_ptr) @ 0x0000000015efc18a 23. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001624c1b2 24. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000162f9c70 25. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x00000000162fa55a 26. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc6653 27. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000000fccc4c3 28. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc3d92 29. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fcca080 30. ? @ 0x00007fbc6213eac3 31. ? @ 0x00007fbc621d0850 (version 25.3.6.10636.altinitytest (altinity build)) 2025.07.28 11:59:13.542619 [ 3964 ] {} test_13.rmt2 (7f9b740d-015c-470e-8cc6-8ba33be0dc63): auto DB::StorageReplicatedMergeTree::processQueueEntry(ReplicatedMergeTreeQueue::SelectedEntryPtr)::(anonymous class)::operator()(LogEntryPtr &) const: Code: 86. DB::HTTPException: Received error from remote server http://146b4357c08d:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Ftest%2F01165%2Ftest_13%2Frmt%2Freplicas%2F1&part=20250728_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.6.10636.altinitytest (altinity build)) '. (RECEIVED_ERROR_FROM_REMOTE_IO_SERVER), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.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 const&, int&&, String const&, unsigned long&&, String const&) @ 0x000000000feda8d9 4. /build/src/IO/HTTPCommon.cpp:104: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x000000000feda6e2 5. /build/src/IO/HTTPCommon.cpp:93: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x000000000feda537 6. /build/src/IO/ReadWriteBufferFromHTTP.cpp:277: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x000000001184a4c4 7. /build/src/IO/ReadWriteBufferFromHTTP.cpp:285: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x000000001184a615 8. /build/src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x000000001184ae59 9. /build/src/IO/ReadWriteBufferFromHTTP.cpp:472: void std::__function::__policy_invoker::__call_impl[abi:se190107]>(std::__function::__policy_storage const*) @ 0x000000001184cedd 10. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001184858b 11. /build/src/IO/ReadWriteBufferFromHTTP.cpp:465: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x000000001184bf0b 12. /build/src/IO/ReadBuffer.h:60: DB::ReadBuffer::next() @ 0x000000000a148c7b 13. /build/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) @ 0x0000000011849fb2 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]>&)>&, 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&) @ 0x0000000011841980 15. /build/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) @ 0x000000001621208e 16. /build/src/Storages/StorageReplicatedMergeTree.cpp:5228: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl[abi:se190107] const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000015f9a5fe 17. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000015ed8bfd 18. /build/src/Storages/StorageReplicatedMergeTree.cpp:2514: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x0000000015ec9aab 19. /build/src/Storages/StorageReplicatedMergeTree.cpp:2349: DB::StorageReplicatedMergeTree::executeLogEntry(DB::ReplicatedMergeTreeLogEntry&) @ 0x0000000015eba91b 20. /build/src/Storages/StorageReplicatedMergeTree.cpp:3876: bool std::__function::__policy_invoker&)>::__call_impl[abi:se190107])::$_1, bool (std::shared_ptr&)>>(std::__function::__policy_storage const*, std::shared_ptr&) @ 0x0000000015f9837e 21. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000165d6fc3 22. /build/src/Storages/StorageReplicatedMergeTree.cpp:3872: DB::StorageReplicatedMergeTree::processQueueEntry(std::shared_ptr) @ 0x0000000015efc18a 23. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001624c1b2 24. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000162f9c70 25. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x00000000162fa55a 26. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc6653 27. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000000fccc4c3 28. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc3d92 29. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fcca080 30. ? @ 0x00007fbc6213eac3 31. ? @ 0x00007fbc621d0850 (version 25.3.6.10636.altinitytest (altinity build)) 2025.07.28 11:59:14.415157 [ 3972 ] {} test_13.rmt2 (7f9b740d-015c-470e-8cc6-8ba33be0dc63): auto DB::StorageReplicatedMergeTree::processQueueEntry(ReplicatedMergeTreeQueue::SelectedEntryPtr)::(anonymous class)::operator()(LogEntryPtr &) const: Code: 86. DB::HTTPException: Received error from remote server http://146b4357c08d:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Ftest%2F01165%2Ftest_13%2Frmt%2Freplicas%2F1&part=20250728_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.6.10636.altinitytest (altinity build)) '. (RECEIVED_ERROR_FROM_REMOTE_IO_SERVER), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.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 const&, int&&, String const&, unsigned long&&, String const&) @ 0x000000000feda8d9 4. /build/src/IO/HTTPCommon.cpp:104: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x000000000feda6e2 5. /build/src/IO/HTTPCommon.cpp:93: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x000000000feda537 6. /build/src/IO/ReadWriteBufferFromHTTP.cpp:277: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x000000001184a4c4 7. /build/src/IO/ReadWriteBufferFromHTTP.cpp:285: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x000000001184a615 8. /build/src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x000000001184ae59 9. /build/src/IO/ReadWriteBufferFromHTTP.cpp:472: void std::__function::__policy_invoker::__call_impl[abi:se190107]>(std::__function::__policy_storage const*) @ 0x000000001184cedd 10. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001184858b 11. /build/src/IO/ReadWriteBufferFromHTTP.cpp:465: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x000000001184bf0b 12. /build/src/IO/ReadBuffer.h:60: DB::ReadBuffer::next() @ 0x000000000a148c7b 13. /build/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) @ 0x0000000011849fb2 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]>&)>&, 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&) @ 0x0000000011841980 15. /build/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) @ 0x000000001621208e 16. /build/src/Storages/StorageReplicatedMergeTree.cpp:5228: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl[abi:se190107] const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000015f9a5fe 17. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000015ed8bfd 18. /build/src/Storages/StorageReplicatedMergeTree.cpp:2514: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x0000000015ec9aab 19. /build/src/Storages/StorageReplicatedMergeTree.cpp:2349: DB::StorageReplicatedMergeTree::executeLogEntry(DB::ReplicatedMergeTreeLogEntry&) @ 0x0000000015eba91b 20. /build/src/Storages/StorageReplicatedMergeTree.cpp:3876: bool std::__function::__policy_invoker&)>::__call_impl[abi:se190107])::$_1, bool (std::shared_ptr&)>>(std::__function::__policy_storage const*, std::shared_ptr&) @ 0x0000000015f9837e 21. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000165d6fc3 22. /build/src/Storages/StorageReplicatedMergeTree.cpp:3872: DB::StorageReplicatedMergeTree::processQueueEntry(std::shared_ptr) @ 0x0000000015efc18a 23. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001624c1b2 24. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000162f9c70 25. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x00000000162fa55a 26. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc6653 27. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000000fccc4c3 28. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc3d92 29. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fcca080 30. ? @ 0x00007fbc6213eac3 31. ? @ 0x00007fbc621d0850 (version 25.3.6.10636.altinitytest (altinity build)) 2025.07.28 11:59:15.022916 [ 3968 ] {} test_13.rmt2 (7f9b740d-015c-470e-8cc6-8ba33be0dc63): auto DB::StorageReplicatedMergeTree::processQueueEntry(ReplicatedMergeTreeQueue::SelectedEntryPtr)::(anonymous class)::operator()(LogEntryPtr &) const: Code: 86. DB::HTTPException: Received error from remote server http://146b4357c08d:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Ftest%2F01165%2Ftest_13%2Frmt%2Freplicas%2F1&part=20250728_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.6.10636.altinitytest (altinity build)) '. (RECEIVED_ERROR_FROM_REMOTE_IO_SERVER), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.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 const&, int&&, String const&, unsigned long&&, String const&) @ 0x000000000feda8d9 4. /build/src/IO/HTTPCommon.cpp:104: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x000000000feda6e2 5. /build/src/IO/HTTPCommon.cpp:93: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x000000000feda537 6. /build/src/IO/ReadWriteBufferFromHTTP.cpp:277: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x000000001184a4c4 7. /build/src/IO/ReadWriteBufferFromHTTP.cpp:285: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x000000001184a615 8. /build/src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x000000001184ae59 9. /build/src/IO/ReadWriteBufferFromHTTP.cpp:472: void std::__function::__policy_invoker::__call_impl[abi:se190107]>(std::__function::__policy_storage const*) @ 0x000000001184cedd 10. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001184858b 11. /build/src/IO/ReadWriteBufferFromHTTP.cpp:465: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x000000001184bf0b 12. /build/src/IO/ReadBuffer.h:60: DB::ReadBuffer::next() @ 0x000000000a148c7b 13. /build/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) @ 0x0000000011849fb2 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]>&)>&, 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&) @ 0x0000000011841980 15. /build/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) @ 0x000000001621208e 16. /build/src/Storages/StorageReplicatedMergeTree.cpp:5228: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl[abi:se190107] const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000015f9a5fe 17. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000015ed8bfd 18. /build/src/Storages/StorageReplicatedMergeTree.cpp:2514: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x0000000015ec9aab 19. /build/src/Storages/StorageReplicatedMergeTree.cpp:2349: DB::StorageReplicatedMergeTree::executeLogEntry(DB::ReplicatedMergeTreeLogEntry&) @ 0x0000000015eba91b 20. /build/src/Storages/StorageReplicatedMergeTree.cpp:3876: bool std::__function::__policy_invoker&)>::__call_impl[abi:se190107])::$_1, bool (std::shared_ptr&)>>(std::__function::__policy_storage const*, std::shared_ptr&) @ 0x0000000015f9837e 21. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000165d6fc3 22. /build/src/Storages/StorageReplicatedMergeTree.cpp:3872: DB::StorageReplicatedMergeTree::processQueueEntry(std::shared_ptr) @ 0x0000000015efc18a 23. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001624c1b2 24. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000162f9c70 25. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x00000000162fa55a 26. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc6653 27. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000000fccc4c3 28. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc3d92 29. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fcca080 30. ? @ 0x00007fbc6213eac3 31. ? @ 0x00007fbc621d0850 (version 25.3.6.10636.altinitytest (altinity build)) 2025.07.28 11:59:16.102488 [ 3962 ] {} test_13.rmt2 (7f9b740d-015c-470e-8cc6-8ba33be0dc63): auto DB::StorageReplicatedMergeTree::processQueueEntry(ReplicatedMergeTreeQueue::SelectedEntryPtr)::(anonymous class)::operator()(LogEntryPtr &) const: Code: 86. DB::HTTPException: Received error from remote server http://146b4357c08d:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Ftest%2F01165%2Ftest_13%2Frmt%2Freplicas%2F1&part=20250728_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.6.10636.altinitytest (altinity build)) '. (RECEIVED_ERROR_FROM_REMOTE_IO_SERVER), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.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 const&, int&&, String const&, unsigned long&&, String const&) @ 0x000000000feda8d9 4. /build/src/IO/HTTPCommon.cpp:104: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x000000000feda6e2 5. /build/src/IO/HTTPCommon.cpp:93: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x000000000feda537 6. /build/src/IO/ReadWriteBufferFromHTTP.cpp:277: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x000000001184a4c4 7. /build/src/IO/ReadWriteBufferFromHTTP.cpp:285: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x000000001184a615 8. /build/src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x000000001184ae59 9. /build/src/IO/ReadWriteBufferFromHTTP.cpp:472: void std::__function::__policy_invoker::__call_impl[abi:se190107]>(std::__function::__policy_storage const*) @ 0x000000001184cedd 10. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001184858b 11. /build/src/IO/ReadWriteBufferFromHTTP.cpp:465: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x000000001184bf0b 12. /build/src/IO/ReadBuffer.h:60: DB::ReadBuffer::next() @ 0x000000000a148c7b 13. /build/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) @ 0x0000000011849fb2 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]>&)>&, 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&) @ 0x0000000011841980 15. /build/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) @ 0x000000001621208e 16. /build/src/Storages/StorageReplicatedMergeTree.cpp:5228: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl[abi:se190107] const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000015f9a5fe 17. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000015ed8bfd 18. /build/src/Storages/StorageReplicatedMergeTree.cpp:2514: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x0000000015ec9aab 19. /build/src/Storages/StorageReplicatedMergeTree.cpp:2349: DB::StorageReplicatedMergeTree::executeLogEntry(DB::ReplicatedMergeTreeLogEntry&) @ 0x0000000015eba91b 20. /build/src/Storages/StorageReplicatedMergeTree.cpp:3876: bool std::__function::__policy_invoker&)>::__call_impl[abi:se190107])::$_1, bool (std::shared_ptr&)>>(std::__function::__policy_storage const*, std::shared_ptr&) @ 0x0000000015f9837e 21. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000165d6fc3 22. /build/src/Storages/StorageReplicatedMergeTree.cpp:3872: DB::StorageReplicatedMergeTree::processQueueEntry(std::shared_ptr) @ 0x0000000015efc18a 23. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001624c1b2 24. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000162f9c70 25. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x00000000162fa55a 26. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc6653 27. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000000fccc4c3 28. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc3d92 29. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fcca080 30. ? @ 0x00007fbc6213eac3 31. ? @ 0x00007fbc621d0850 (version 25.3.6.10636.altinitytest (altinity build)) 2025.07.28 11:59:16.803853 [ 3965 ] {} test_13.rmt2 (7f9b740d-015c-470e-8cc6-8ba33be0dc63): auto DB::StorageReplicatedMergeTree::processQueueEntry(ReplicatedMergeTreeQueue::SelectedEntryPtr)::(anonymous class)::operator()(LogEntryPtr &) const: Code: 86. DB::HTTPException: Received error from remote server http://146b4357c08d:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Ftest%2F01165%2Ftest_13%2Frmt%2Freplicas%2F1&part=20250728_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.6.10636.altinitytest (altinity build)) '. (RECEIVED_ERROR_FROM_REMOTE_IO_SERVER), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.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 const&, int&&, String const&, unsigned long&&, String const&) @ 0x000000000feda8d9 4. /build/src/IO/HTTPCommon.cpp:104: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x000000000feda6e2 5. /build/src/IO/HTTPCommon.cpp:93: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x000000000feda537 6. /build/src/IO/ReadWriteBufferFromHTTP.cpp:277: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x000000001184a4c4 7. /build/src/IO/ReadWriteBufferFromHTTP.cpp:285: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x000000001184a615 8. /build/src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x000000001184ae59 9. /build/src/IO/ReadWriteBufferFromHTTP.cpp:472: void std::__function::__policy_invoker::__call_impl[abi:se190107]>(std::__function::__policy_storage const*) @ 0x000000001184cedd 10. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001184858b 11. /build/src/IO/ReadWriteBufferFromHTTP.cpp:465: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x000000001184bf0b 12. /build/src/IO/ReadBuffer.h:60: DB::ReadBuffer::next() @ 0x000000000a148c7b 13. /build/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) @ 0x0000000011849fb2 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]>&)>&, 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&) @ 0x0000000011841980 15. /build/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) @ 0x000000001621208e 16. /build/src/Storages/StorageReplicatedMergeTree.cpp:5228: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl[abi:se190107] const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000015f9a5fe 17. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000015ed8bfd 18. /build/src/Storages/StorageReplicatedMergeTree.cpp:2514: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x0000000015ec9aab 19. /build/src/Storages/StorageReplicatedMergeTree.cpp:2349: DB::StorageReplicatedMergeTree::executeLogEntry(DB::ReplicatedMergeTreeLogEntry&) @ 0x0000000015eba91b 20. /build/src/Storages/StorageReplicatedMergeTree.cpp:3876: bool std::__function::__policy_invoker&)>::__call_impl[abi:se190107])::$_1, bool (std::shared_ptr&)>>(std::__function::__policy_storage const*, std::shared_ptr&) @ 0x0000000015f9837e 21. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000165d6fc3 22. /build/src/Storages/StorageReplicatedMergeTree.cpp:3872: DB::StorageReplicatedMergeTree::processQueueEntry(std::shared_ptr) @ 0x0000000015efc18a 23. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001624c1b2 24. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000162f9c70 25. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x00000000162fa55a 26. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc6653 27. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000000fccc4c3 28. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc3d92 29. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fcca080 30. ? @ 0x00007fbc6213eac3 31. ? @ 0x00007fbc621d0850 (version 25.3.6.10636.altinitytest (altinity build)) 2025.07.28 11:59:17.406524 [ 3976 ] {} test_13.rmt2 (7f9b740d-015c-470e-8cc6-8ba33be0dc63): auto DB::StorageReplicatedMergeTree::processQueueEntry(ReplicatedMergeTreeQueue::SelectedEntryPtr)::(anonymous class)::operator()(LogEntryPtr &) const: Code: 86. DB::HTTPException: Received error from remote server http://146b4357c08d:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Ftest%2F01165%2Ftest_13%2Frmt%2Freplicas%2F1&part=20250728_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.6.10636.altinitytest (altinity build)) '. (RECEIVED_ERROR_FROM_REMOTE_IO_SERVER), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.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 const&, int&&, String const&, unsigned long&&, String const&) @ 0x000000000feda8d9 4. /build/src/IO/HTTPCommon.cpp:104: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x000000000feda6e2 5. /build/src/IO/HTTPCommon.cpp:93: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x000000000feda537 6. /build/src/IO/ReadWriteBufferFromHTTP.cpp:277: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x000000001184a4c4 7. /build/src/IO/ReadWriteBufferFromHTTP.cpp:285: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x000000001184a615 8. /build/src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x000000001184ae59 9. /build/src/IO/ReadWriteBufferFromHTTP.cpp:472: void std::__function::__policy_invoker::__call_impl[abi:se190107]>(std::__function::__policy_storage const*) @ 0x000000001184cedd 10. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001184858b 11. /build/src/IO/ReadWriteBufferFromHTTP.cpp:465: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x000000001184bf0b 12. /build/src/IO/ReadBuffer.h:60: DB::ReadBuffer::next() @ 0x000000000a148c7b 13. /build/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) @ 0x0000000011849fb2 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]>&)>&, 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&) @ 0x0000000011841980 15. /build/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) @ 0x000000001621208e 16. /build/src/Storages/StorageReplicatedMergeTree.cpp:5228: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl[abi:se190107] const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000015f9a5fe 17. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000015ed8bfd 18. /build/src/Storages/StorageReplicatedMergeTree.cpp:2514: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x0000000015ec9aab 19. /build/src/Storages/StorageReplicatedMergeTree.cpp:2349: DB::StorageReplicatedMergeTree::executeLogEntry(DB::ReplicatedMergeTreeLogEntry&) @ 0x0000000015eba91b 20. /build/src/Storages/StorageReplicatedMergeTree.cpp:3876: bool std::__function::__policy_invoker&)>::__call_impl[abi:se190107])::$_1, bool (std::shared_ptr&)>>(std::__function::__policy_storage const*, std::shared_ptr&) @ 0x0000000015f9837e 21. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000165d6fc3 22. /build/src/Storages/StorageReplicatedMergeTree.cpp:3872: DB::StorageReplicatedMergeTree::processQueueEntry(std::shared_ptr) @ 0x0000000015efc18a 23. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001624c1b2 24. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000162f9c70 25. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x00000000162fa55a 26. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc6653 27. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000000fccc4c3 28. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc3d92 29. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fcca080 30. ? @ 0x00007fbc6213eac3 31. ? @ 0x00007fbc621d0850 (version 25.3.6.10636.altinitytest (altinity build)) 2025.07.28 11:59:18.364735 [ 3977 ] {} test_13.rmt2 (7f9b740d-015c-470e-8cc6-8ba33be0dc63): auto DB::StorageReplicatedMergeTree::processQueueEntry(ReplicatedMergeTreeQueue::SelectedEntryPtr)::(anonymous class)::operator()(LogEntryPtr &) const: Code: 86. DB::HTTPException: Received error from remote server http://146b4357c08d:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Ftest%2F01165%2Ftest_13%2Frmt%2Freplicas%2F1&part=20250728_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.6.10636.altinitytest (altinity build)) '. (RECEIVED_ERROR_FROM_REMOTE_IO_SERVER), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.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 const&, int&&, String const&, unsigned long&&, String const&) @ 0x000000000feda8d9 4. /build/src/IO/HTTPCommon.cpp:104: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x000000000feda6e2 5. /build/src/IO/HTTPCommon.cpp:93: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x000000000feda537 6. /build/src/IO/ReadWriteBufferFromHTTP.cpp:277: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x000000001184a4c4 7. /build/src/IO/ReadWriteBufferFromHTTP.cpp:285: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x000000001184a615 8. /build/src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x000000001184ae59 9. /build/src/IO/ReadWriteBufferFromHTTP.cpp:472: void std::__function::__policy_invoker::__call_impl[abi:se190107]>(std::__function::__policy_storage const*) @ 0x000000001184cedd 10. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001184858b 11. /build/src/IO/ReadWriteBufferFromHTTP.cpp:465: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x000000001184bf0b 12. /build/src/IO/ReadBuffer.h:60: DB::ReadBuffer::next() @ 0x000000000a148c7b 13. /build/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) @ 0x0000000011849fb2 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]>&)>&, 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&) @ 0x0000000011841980 15. /build/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) @ 0x000000001621208e 16. /build/src/Storages/StorageReplicatedMergeTree.cpp:5228: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl[abi:se190107] const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000015f9a5fe 17. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000015ed8bfd 18. /build/src/Storages/StorageReplicatedMergeTree.cpp:2514: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x0000000015ec9aab 19. /build/src/Storages/StorageReplicatedMergeTree.cpp:2349: DB::StorageReplicatedMergeTree::executeLogEntry(DB::ReplicatedMergeTreeLogEntry&) @ 0x0000000015eba91b 20. /build/src/Storages/StorageReplicatedMergeTree.cpp:3876: bool std::__function::__policy_invoker&)>::__call_impl[abi:se190107])::$_1, bool (std::shared_ptr&)>>(std::__function::__policy_storage const*, std::shared_ptr&) @ 0x0000000015f9837e 21. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000165d6fc3 22. /build/src/Storages/StorageReplicatedMergeTree.cpp:3872: DB::StorageReplicatedMergeTree::processQueueEntry(std::shared_ptr) @ 0x0000000015efc18a 23. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001624c1b2 24. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000162f9c70 25. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x00000000162fa55a 26. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc6653 27. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000000fccc4c3 28. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc3d92 29. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fcca080 30. ? @ 0x00007fbc6213eac3 31. ? @ 0x00007fbc621d0850 (version 25.3.6.10636.altinitytest (altinity build)) 2025.07.28 11:59:18.602340 [ 3971 ] {} test_13.rmt2 (7f9b740d-015c-470e-8cc6-8ba33be0dc63): auto DB::StorageReplicatedMergeTree::processQueueEntry(ReplicatedMergeTreeQueue::SelectedEntryPtr)::(anonymous class)::operator()(LogEntryPtr &) const: Code: 86. DB::HTTPException: Received error from remote server http://146b4357c08d:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Ftest%2F01165%2Ftest_13%2Frmt%2Freplicas%2F1&part=20250728_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.6.10636.altinitytest (altinity build)) '. (RECEIVED_ERROR_FROM_REMOTE_IO_SERVER), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.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 const&, int&&, String const&, unsigned long&&, String const&) @ 0x000000000feda8d9 4. /build/src/IO/HTTPCommon.cpp:104: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x000000000feda6e2 5. /build/src/IO/HTTPCommon.cpp:93: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x000000000feda537 6. /build/src/IO/ReadWriteBufferFromHTTP.cpp:277: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x000000001184a4c4 7. /build/src/IO/ReadWriteBufferFromHTTP.cpp:285: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x000000001184a615 8. /build/src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x000000001184ae59 9. /build/src/IO/ReadWriteBufferFromHTTP.cpp:472: void std::__function::__policy_invoker::__call_impl[abi:se190107]>(std::__function::__policy_storage const*) @ 0x000000001184cedd 10. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001184858b 11. /build/src/IO/ReadWriteBufferFromHTTP.cpp:465: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x000000001184bf0b 12. /build/src/IO/ReadBuffer.h:60: DB::ReadBuffer::next() @ 0x000000000a148c7b 13. /build/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) @ 0x0000000011849fb2 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]>&)>&, 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&) @ 0x0000000011841980 15. /build/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) @ 0x000000001621208e 16. /build/src/Storages/StorageReplicatedMergeTree.cpp:5228: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl[abi:se190107] const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000015f9a5fe 17. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000015ed8bfd 18. /build/src/Storages/StorageReplicatedMergeTree.cpp:2514: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x0000000015ec9aab 19. /build/src/Storages/StorageReplicatedMergeTree.cpp:2349: DB::StorageReplicatedMergeTree::executeLogEntry(DB::ReplicatedMergeTreeLogEntry&) @ 0x0000000015eba91b 20. /build/src/Storages/StorageReplicatedMergeTree.cpp:3876: bool std::__function::__policy_invoker&)>::__call_impl[abi:se190107])::$_1, bool (std::shared_ptr&)>>(std::__function::__policy_storage const*, std::shared_ptr&) @ 0x0000000015f9837e 21. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000165d6fc3 22. /build/src/Storages/StorageReplicatedMergeTree.cpp:3872: DB::StorageReplicatedMergeTree::processQueueEntry(std::shared_ptr) @ 0x0000000015efc18a 23. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001624c1b2 24. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000162f9c70 25. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x00000000162fa55a 26. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc6653 27. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000000fccc4c3 28. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc3d92 29. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fcca080 30. ? @ 0x00007fbc6213eac3 31. ? @ 0x00007fbc621d0850 (version 25.3.6.10636.altinitytest (altinity build)) 2025.07.28 11:59:19.198974 [ 5951 ] {f4ba95b6-15d3-4299-881f-4999c9904642} executeQuery: Code: 169. DB::Exception: ASOF join not supported for type: String. (BAD_TYPE_OF_FIELD) (version 25.3.6.10636.altinitytest (altinity build)) (from [::1]:50950) (comment: 01139_asof_join_types.sql) (query 14, line 18) (in query: select * from (select 0 as k, 'x' as v) t1 asof join (select 0 as k, 'x' as v) t2 using(k, v);), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x000000000a06b56b 4. /build/src/Interpreters/RowRefs.cpp:267: DB::SortedLookupVectorBase::getTypeSize(DB::IColumn const&, unsigned long&) @ 0x0000000014dd570a 5. /build/src/Interpreters/HashJoin/HashJoin.cpp:228: DB::HashJoin::HashJoin(std::shared_ptr, DB::Block const&, bool, unsigned long, String const&, bool) @ 0x0000000014d7868b 6. /build/contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: DB::HashJoin* std::construct_at[abi:se190107]&, DB::Block const&, bool const&, DB::HashJoin*>(DB::HashJoin*, std::shared_ptr&, DB::Block const&, bool const&) @ 0x00000000149c79c9 7. /build/contrib/llvm-project/libcxx/include/__memory/construct_at.h:49: DB::chooseJoinAlgorithm(std::shared_ptr&, DB::PreparedJoinStorage const&, DB::Block const&, DB::Block const&, DB::JoinAlgorithmSettings const&, unsigned long, std::optional) @ 0x00000000149c587d 8. /build/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) @ 0x0000000016de9821 9. /build/src/Processors/QueryPlan/Optimizations/optimizeJoin.cpp:251: DB::QueryPlanOptimizations::convertLogicalJoinToPhysical(DB::QueryPlan::Node&, std::list>&, DB::QueryPlanOptimizationSettings const&, std::optional) @ 0x0000000016eb5ce9 10. /build/src/Processors/QueryPlan/Optimizations/optimizeTree.cpp:158: DB::QueryPlanOptimizations::optimizeTreeSecondPass(DB::QueryPlanOptimizationSettings const&, DB::QueryPlan::Node&, std::list>&) @ 0x0000000016ead357 11. /build/src/Processors/QueryPlan/QueryPlan.cpp:487: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x0000000016e0055c 12. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:275: DB::InterpreterSelectQueryAnalyzer::buildQueryPipeline() @ 0x0000000014974614 13. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:242: DB::InterpreterSelectQueryAnalyzer::execute() @ 0x000000001497439e 14. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88dc9 15. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 16. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 17. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 18. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 19. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 20. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 21. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 22. ? @ 0x00007fbc6213eac3 23. ? @ 0x00007fbc621d0850 2025.07.28 11:59:19.225530 [ 5951 ] {} TCPHandler: Code: 169. DB::Exception: ASOF join not supported for type: String. (BAD_TYPE_OF_FIELD), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x000000000a06b56b 4. /build/src/Interpreters/RowRefs.cpp:267: DB::SortedLookupVectorBase::getTypeSize(DB::IColumn const&, unsigned long&) @ 0x0000000014dd570a 5. /build/src/Interpreters/HashJoin/HashJoin.cpp:228: DB::HashJoin::HashJoin(std::shared_ptr, DB::Block const&, bool, unsigned long, String const&, bool) @ 0x0000000014d7868b 6. /build/contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: DB::HashJoin* std::construct_at[abi:se190107]&, DB::Block const&, bool const&, DB::HashJoin*>(DB::HashJoin*, std::shared_ptr&, DB::Block const&, bool const&) @ 0x00000000149c79c9 7. /build/contrib/llvm-project/libcxx/include/__memory/construct_at.h:49: DB::chooseJoinAlgorithm(std::shared_ptr&, DB::PreparedJoinStorage const&, DB::Block const&, DB::Block const&, DB::JoinAlgorithmSettings const&, unsigned long, std::optional) @ 0x00000000149c587d 8. /build/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) @ 0x0000000016de9821 9. /build/src/Processors/QueryPlan/Optimizations/optimizeJoin.cpp:251: DB::QueryPlanOptimizations::convertLogicalJoinToPhysical(DB::QueryPlan::Node&, std::list>&, DB::QueryPlanOptimizationSettings const&, std::optional) @ 0x0000000016eb5ce9 10. /build/src/Processors/QueryPlan/Optimizations/optimizeTree.cpp:158: DB::QueryPlanOptimizations::optimizeTreeSecondPass(DB::QueryPlanOptimizationSettings const&, DB::QueryPlan::Node&, std::list>&) @ 0x0000000016ead357 11. /build/src/Processors/QueryPlan/QueryPlan.cpp:487: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x0000000016e0055c 12. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:275: DB::InterpreterSelectQueryAnalyzer::buildQueryPipeline() @ 0x0000000014974614 13. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:242: DB::InterpreterSelectQueryAnalyzer::execute() @ 0x000000001497439e 14. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88dc9 15. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 16. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 17. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 18. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 19. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 20. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 21. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 22. ? @ 0x00007fbc6213eac3 23. ? @ 0x00007fbc621d0850 2025.07.28 11:59:19.527378 [ 3967 ] {} test_13.rmt2 (7f9b740d-015c-470e-8cc6-8ba33be0dc63): auto DB::StorageReplicatedMergeTree::processQueueEntry(ReplicatedMergeTreeQueue::SelectedEntryPtr)::(anonymous class)::operator()(LogEntryPtr &) const: Code: 86. DB::HTTPException: Received error from remote server http://146b4357c08d:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Ftest%2F01165%2Ftest_13%2Frmt%2Freplicas%2F1&part=20250728_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.6.10636.altinitytest (altinity build)) '. (RECEIVED_ERROR_FROM_REMOTE_IO_SERVER), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.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 const&, int&&, String const&, unsigned long&&, String const&) @ 0x000000000feda8d9 4. /build/src/IO/HTTPCommon.cpp:104: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x000000000feda6e2 5. /build/src/IO/HTTPCommon.cpp:93: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x000000000feda537 6. /build/src/IO/ReadWriteBufferFromHTTP.cpp:277: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x000000001184a4c4 7. /build/src/IO/ReadWriteBufferFromHTTP.cpp:285: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x000000001184a615 8. /build/src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x000000001184ae59 9. /build/src/IO/ReadWriteBufferFromHTTP.cpp:472: void std::__function::__policy_invoker::__call_impl[abi:se190107]>(std::__function::__policy_storage const*) @ 0x000000001184cedd 10. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001184858b 11. /build/src/IO/ReadWriteBufferFromHTTP.cpp:465: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x000000001184bf0b 12. /build/src/IO/ReadBuffer.h:60: DB::ReadBuffer::next() @ 0x000000000a148c7b 13. /build/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) @ 0x0000000011849fb2 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]>&)>&, 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&) @ 0x0000000011841980 15. /build/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) @ 0x000000001621208e 16. /build/src/Storages/StorageReplicatedMergeTree.cpp:5228: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl[abi:se190107] const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000015f9a5fe 17. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000015ed8bfd 18. /build/src/Storages/StorageReplicatedMergeTree.cpp:2514: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x0000000015ec9aab 19. /build/src/Storages/StorageReplicatedMergeTree.cpp:2349: DB::StorageReplicatedMergeTree::executeLogEntry(DB::ReplicatedMergeTreeLogEntry&) @ 0x0000000015eba91b 20. /build/src/Storages/StorageReplicatedMergeTree.cpp:3876: bool std::__function::__policy_invoker&)>::__call_impl[abi:se190107])::$_1, bool (std::shared_ptr&)>>(std::__function::__policy_storage const*, std::shared_ptr&) @ 0x0000000015f9837e 21. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000165d6fc3 22. /build/src/Storages/StorageReplicatedMergeTree.cpp:3872: DB::StorageReplicatedMergeTree::processQueueEntry(std::shared_ptr) @ 0x0000000015efc18a 23. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001624c1b2 24. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000162f9c70 25. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x00000000162fa55a 26. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc6653 27. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000000fccc4c3 28. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc3d92 29. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fcca080 30. ? @ 0x00007fbc6213eac3 31. ? @ 0x00007fbc621d0850 (version 25.3.6.10636.altinitytest (altinity build)) 2025.07.28 11:59:19.925413 [ 3287 ] {56b3969f-358d-41e6-a56b-3e3a744193c2} executeQuery: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION) (version 25.3.6.10636.altinitytest (altinity build)) (from [::1]:51136) (comment: 02771_semi_join_use_nulls.gen.sql) (query 1, line 2) (in query: SET enable_analyzer = 0;), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x000000000c25bc4b 4. /build/src/Access/SettingsConstraints.cpp:343: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000138596e3 5. /build/src/Access/SettingsConstraints.cpp:300: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000013858faf 6. /build/src/Access/SettingsConstraints.cpp:194: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges const&, DB::SettingSource) const @ 0x00000000138591b3 7. /build/src/Interpreters/Context.cpp:2722: DB::Context::checkSettingsConstraints(DB::SettingsChanges const&, DB::SettingSource) @ 0x0000000014436509 8. /build/src/Interpreters/InterpreterSetQuery.cpp:28: DB::InterpreterSetQuery::execute() @ 0x00000000149e240a 9. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88dc9 10. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 11. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 12. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 13. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 14. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 16. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 17. ? @ 0x00007fbc6213eac3 18. ? @ 0x00007fbc621d0850 2025.07.28 11:59:19.954943 [ 3287 ] {} 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. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x000000000c25bc4b 4. /build/src/Access/SettingsConstraints.cpp:343: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000138596e3 5. /build/src/Access/SettingsConstraints.cpp:300: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000013858faf 6. /build/src/Access/SettingsConstraints.cpp:194: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges const&, DB::SettingSource) const @ 0x00000000138591b3 7. /build/src/Interpreters/Context.cpp:2722: DB::Context::checkSettingsConstraints(DB::SettingsChanges const&, DB::SettingSource) @ 0x0000000014436509 8. /build/src/Interpreters/InterpreterSetQuery.cpp:28: DB::InterpreterSetQuery::execute() @ 0x00000000149e240a 9. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88dc9 10. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 11. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 12. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 13. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 14. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 16. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 17. ? @ 0x00007fbc6213eac3 18. ? @ 0x00007fbc621d0850 2025.07.28 11:59:20.244960 [ 3963 ] {} test_13.rmt2 (7f9b740d-015c-470e-8cc6-8ba33be0dc63): auto DB::StorageReplicatedMergeTree::processQueueEntry(ReplicatedMergeTreeQueue::SelectedEntryPtr)::(anonymous class)::operator()(LogEntryPtr &) const: Code: 86. DB::HTTPException: Received error from remote server http://146b4357c08d:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Ftest%2F01165%2Ftest_13%2Frmt%2Freplicas%2F1&part=20250728_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.6.10636.altinitytest (altinity build)) '. (RECEIVED_ERROR_FROM_REMOTE_IO_SERVER), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.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 const&, int&&, String const&, unsigned long&&, String const&) @ 0x000000000feda8d9 4. /build/src/IO/HTTPCommon.cpp:104: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x000000000feda6e2 5. /build/src/IO/HTTPCommon.cpp:93: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x000000000feda537 6. /build/src/IO/ReadWriteBufferFromHTTP.cpp:277: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x000000001184a4c4 7. /build/src/IO/ReadWriteBufferFromHTTP.cpp:285: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x000000001184a615 8. /build/src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x000000001184ae59 9. /build/src/IO/ReadWriteBufferFromHTTP.cpp:472: void std::__function::__policy_invoker::__call_impl[abi:se190107]>(std::__function::__policy_storage const*) @ 0x000000001184cedd 10. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001184858b 11. /build/src/IO/ReadWriteBufferFromHTTP.cpp:465: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x000000001184bf0b 12. /build/src/IO/ReadBuffer.h:60: DB::ReadBuffer::next() @ 0x000000000a148c7b 13. /build/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) @ 0x0000000011849fb2 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]>&)>&, 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&) @ 0x0000000011841980 15. /build/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) @ 0x000000001621208e 16. /build/src/Storages/StorageReplicatedMergeTree.cpp:5228: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl[abi:se190107] const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000015f9a5fe 17. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000015ed8bfd 18. /build/src/Storages/StorageReplicatedMergeTree.cpp:2514: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x0000000015ec9aab 19. /build/src/Storages/StorageReplicatedMergeTree.cpp:2349: DB::StorageReplicatedMergeTree::executeLogEntry(DB::ReplicatedMergeTreeLogEntry&) @ 0x0000000015eba91b 20. /build/src/Storages/StorageReplicatedMergeTree.cpp:3876: bool std::__function::__policy_invoker&)>::__call_impl[abi:se190107])::$_1, bool (std::shared_ptr&)>>(std::__function::__policy_storage const*, std::shared_ptr&) @ 0x0000000015f9837e 21. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000165d6fc3 22. /build/src/Storages/StorageReplicatedMergeTree.cpp:3872: DB::StorageReplicatedMergeTree::processQueueEntry(std::shared_ptr) @ 0x0000000015efc18a 23. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001624c1b2 24. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000162f9c70 25. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x00000000162fa55a 26. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc6653 27. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000000fccc4c3 28. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc3d92 29. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fcca080 30. ? @ 0x00007fbc6213eac3 31. ? @ 0x00007fbc621d0850 (version 25.3.6.10636.altinitytest (altinity build)) 2025.07.28 11:59:20.770910 [ 3971 ] {} test_13.rmt2 (7f9b740d-015c-470e-8cc6-8ba33be0dc63): auto DB::StorageReplicatedMergeTree::processQueueEntry(ReplicatedMergeTreeQueue::SelectedEntryPtr)::(anonymous class)::operator()(LogEntryPtr &) const: Code: 86. DB::HTTPException: Received error from remote server http://146b4357c08d:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Ftest%2F01165%2Ftest_13%2Frmt%2Freplicas%2F1&part=20250728_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.6.10636.altinitytest (altinity build)) '. (RECEIVED_ERROR_FROM_REMOTE_IO_SERVER), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.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 const&, int&&, String const&, unsigned long&&, String const&) @ 0x000000000feda8d9 4. /build/src/IO/HTTPCommon.cpp:104: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x000000000feda6e2 5. /build/src/IO/HTTPCommon.cpp:93: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x000000000feda537 6. /build/src/IO/ReadWriteBufferFromHTTP.cpp:277: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x000000001184a4c4 7. /build/src/IO/ReadWriteBufferFromHTTP.cpp:285: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x000000001184a615 8. /build/src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x000000001184ae59 9. /build/src/IO/ReadWriteBufferFromHTTP.cpp:472: void std::__function::__policy_invoker::__call_impl[abi:se190107]>(std::__function::__policy_storage const*) @ 0x000000001184cedd 10. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001184858b 11. /build/src/IO/ReadWriteBufferFromHTTP.cpp:465: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x000000001184bf0b 12. /build/src/IO/ReadBuffer.h:60: DB::ReadBuffer::next() @ 0x000000000a148c7b 13. /build/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) @ 0x0000000011849fb2 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]>&)>&, 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&) @ 0x0000000011841980 15. /build/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) @ 0x000000001621208e 16. /build/src/Storages/StorageReplicatedMergeTree.cpp:5228: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl[abi:se190107] const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000015f9a5fe 17. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000015ed8bfd 18. /build/src/Storages/StorageReplicatedMergeTree.cpp:2514: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x0000000015ec9aab 19. /build/src/Storages/StorageReplicatedMergeTree.cpp:2349: DB::StorageReplicatedMergeTree::executeLogEntry(DB::ReplicatedMergeTreeLogEntry&) @ 0x0000000015eba91b 20. /build/src/Storages/StorageReplicatedMergeTree.cpp:3876: bool std::__function::__policy_invoker&)>::__call_impl[abi:se190107])::$_1, bool (std::shared_ptr&)>>(std::__function::__policy_storage const*, std::shared_ptr&) @ 0x0000000015f9837e 21. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000165d6fc3 22. /build/src/Storages/StorageReplicatedMergeTree.cpp:3872: DB::StorageReplicatedMergeTree::processQueueEntry(std::shared_ptr) @ 0x0000000015efc18a 23. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001624c1b2 24. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000162f9c70 25. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x00000000162fa55a 26. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc6653 27. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000000fccc4c3 28. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc3d92 29. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fcca080 30. ? @ 0x00007fbc6213eac3 31. ? @ 0x00007fbc621d0850 (version 25.3.6.10636.altinitytest (altinity build)) 2025.07.28 11:59:21.351664 [ 3972 ] {} test_13.rmt2 (7f9b740d-015c-470e-8cc6-8ba33be0dc63): auto DB::StorageReplicatedMergeTree::processQueueEntry(ReplicatedMergeTreeQueue::SelectedEntryPtr)::(anonymous class)::operator()(LogEntryPtr &) const: Code: 86. DB::HTTPException: Received error from remote server http://146b4357c08d:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Ftest%2F01165%2Ftest_13%2Frmt%2Freplicas%2F1&part=20250728_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.6.10636.altinitytest (altinity build)) '. (RECEIVED_ERROR_FROM_REMOTE_IO_SERVER), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.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 const&, int&&, String const&, unsigned long&&, String const&) @ 0x000000000feda8d9 4. /build/src/IO/HTTPCommon.cpp:104: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x000000000feda6e2 5. /build/src/IO/HTTPCommon.cpp:93: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x000000000feda537 6. /build/src/IO/ReadWriteBufferFromHTTP.cpp:277: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x000000001184a4c4 7. /build/src/IO/ReadWriteBufferFromHTTP.cpp:285: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x000000001184a615 8. /build/src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x000000001184ae59 9. /build/src/IO/ReadWriteBufferFromHTTP.cpp:472: void std::__function::__policy_invoker::__call_impl[abi:se190107]>(std::__function::__policy_storage const*) @ 0x000000001184cedd 10. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001184858b 11. /build/src/IO/ReadWriteBufferFromHTTP.cpp:465: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x000000001184bf0b 12. /build/src/IO/ReadBuffer.h:60: DB::ReadBuffer::next() @ 0x000000000a148c7b 13. /build/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) @ 0x0000000011849fb2 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]>&)>&, 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&) @ 0x0000000011841980 15. /build/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) @ 0x000000001621208e 16. /build/src/Storages/StorageReplicatedMergeTree.cpp:5228: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl[abi:se190107] const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000015f9a5fe 17. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000015ed8bfd 18. /build/src/Storages/StorageReplicatedMergeTree.cpp:2514: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x0000000015ec9aab 19. /build/src/Storages/StorageReplicatedMergeTree.cpp:2349: DB::StorageReplicatedMergeTree::executeLogEntry(DB::ReplicatedMergeTreeLogEntry&) @ 0x0000000015eba91b 20. /build/src/Storages/StorageReplicatedMergeTree.cpp:3876: bool std::__function::__policy_invoker&)>::__call_impl[abi:se190107])::$_1, bool (std::shared_ptr&)>>(std::__function::__policy_storage const*, std::shared_ptr&) @ 0x0000000015f9837e 21. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000165d6fc3 22. /build/src/Storages/StorageReplicatedMergeTree.cpp:3872: DB::StorageReplicatedMergeTree::processQueueEntry(std::shared_ptr) @ 0x0000000015efc18a 23. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001624c1b2 24. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000162f9c70 25. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x00000000162fa55a 26. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc6653 27. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000000fccc4c3 28. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc3d92 29. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fcca080 30. ? @ 0x00007fbc6213eac3 31. ? @ 0x00007fbc621d0850 (version 25.3.6.10636.altinitytest (altinity build)) 2025.07.28 11:59:21.470023 [ 3976 ] {} test_13.rmt2 (7f9b740d-015c-470e-8cc6-8ba33be0dc63): auto DB::StorageReplicatedMergeTree::processQueueEntry(ReplicatedMergeTreeQueue::SelectedEntryPtr)::(anonymous class)::operator()(LogEntryPtr &) const: Code: 86. DB::HTTPException: Received error from remote server http://146b4357c08d:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Ftest%2F01165%2Ftest_13%2Frmt%2Freplicas%2F1&part=20250728_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.6.10636.altinitytest (altinity build)) '. (RECEIVED_ERROR_FROM_REMOTE_IO_SERVER), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.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 const&, int&&, String const&, unsigned long&&, String const&) @ 0x000000000feda8d9 4. /build/src/IO/HTTPCommon.cpp:104: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x000000000feda6e2 5. /build/src/IO/HTTPCommon.cpp:93: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x000000000feda537 6. /build/src/IO/ReadWriteBufferFromHTTP.cpp:277: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x000000001184a4c4 7. /build/src/IO/ReadWriteBufferFromHTTP.cpp:285: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x000000001184a615 8. /build/src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x000000001184ae59 9. /build/src/IO/ReadWriteBufferFromHTTP.cpp:472: void std::__function::__policy_invoker::__call_impl[abi:se190107]>(std::__function::__policy_storage const*) @ 0x000000001184cedd 10. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001184858b 11. /build/src/IO/ReadWriteBufferFromHTTP.cpp:465: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x000000001184bf0b 12. /build/src/IO/ReadBuffer.h:60: DB::ReadBuffer::next() @ 0x000000000a148c7b 13. /build/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) @ 0x0000000011849fb2 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]>&)>&, 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&) @ 0x0000000011841980 15. /build/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) @ 0x000000001621208e 16. /build/src/Storages/StorageReplicatedMergeTree.cpp:5228: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl[abi:se190107] const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000015f9a5fe 17. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000015ed8bfd 18. /build/src/Storages/StorageReplicatedMergeTree.cpp:2514: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x0000000015ec9aab 19. /build/src/Storages/StorageReplicatedMergeTree.cpp:2349: DB::StorageReplicatedMergeTree::executeLogEntry(DB::ReplicatedMergeTreeLogEntry&) @ 0x0000000015eba91b 20. /build/src/Storages/StorageReplicatedMergeTree.cpp:3876: bool std::__function::__policy_invoker&)>::__call_impl[abi:se190107])::$_1, bool (std::shared_ptr&)>>(std::__function::__policy_storage const*, std::shared_ptr&) @ 0x0000000015f9837e 21. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000165d6fc3 22. /build/src/Storages/StorageReplicatedMergeTree.cpp:3872: DB::StorageReplicatedMergeTree::processQueueEntry(std::shared_ptr) @ 0x0000000015efc18a 23. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001624c1b2 24. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000162f9c70 25. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x00000000162fa55a 26. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc6653 27. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000000fccc4c3 28. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc3d92 29. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fcca080 30. ? @ 0x00007fbc6213eac3 31. ? @ 0x00007fbc621d0850 (version 25.3.6.10636.altinitytest (altinity build)) 2025.07.28 11:59:22.127995 [ 3968 ] {} test_13.rmt2 (7f9b740d-015c-470e-8cc6-8ba33be0dc63): auto DB::StorageReplicatedMergeTree::processQueueEntry(ReplicatedMergeTreeQueue::SelectedEntryPtr)::(anonymous class)::operator()(LogEntryPtr &) const: Code: 86. DB::HTTPException: Received error from remote server http://146b4357c08d:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Ftest%2F01165%2Ftest_13%2Frmt%2Freplicas%2F1&part=20250728_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.6.10636.altinitytest (altinity build)) '. (RECEIVED_ERROR_FROM_REMOTE_IO_SERVER), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.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 const&, int&&, String const&, unsigned long&&, String const&) @ 0x000000000feda8d9 4. /build/src/IO/HTTPCommon.cpp:104: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x000000000feda6e2 5. /build/src/IO/HTTPCommon.cpp:93: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x000000000feda537 6. /build/src/IO/ReadWriteBufferFromHTTP.cpp:277: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x000000001184a4c4 7. /build/src/IO/ReadWriteBufferFromHTTP.cpp:285: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x000000001184a615 8. /build/src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x000000001184ae59 9. /build/src/IO/ReadWriteBufferFromHTTP.cpp:472: void std::__function::__policy_invoker::__call_impl[abi:se190107]>(std::__function::__policy_storage const*) @ 0x000000001184cedd 10. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001184858b 11. /build/src/IO/ReadWriteBufferFromHTTP.cpp:465: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x000000001184bf0b 12. /build/src/IO/ReadBuffer.h:60: DB::ReadBuffer::next() @ 0x000000000a148c7b 13. /build/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) @ 0x0000000011849fb2 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]>&)>&, 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&) @ 0x0000000011841980 15. /build/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) @ 0x000000001621208e 16. /build/src/Storages/StorageReplicatedMergeTree.cpp:5228: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl[abi:se190107] const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000015f9a5fe 17. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000015ed8bfd 18. /build/src/Storages/StorageReplicatedMergeTree.cpp:2514: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x0000000015ec9aab 19. /build/src/Storages/StorageReplicatedMergeTree.cpp:2349: DB::StorageReplicatedMergeTree::executeLogEntry(DB::ReplicatedMergeTreeLogEntry&) @ 0x0000000015eba91b 20. /build/src/Storages/StorageReplicatedMergeTree.cpp:3876: bool std::__function::__policy_invoker&)>::__call_impl[abi:se190107])::$_1, bool (std::shared_ptr&)>>(std::__function::__policy_storage const*, std::shared_ptr&) @ 0x0000000015f9837e 21. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000165d6fc3 22. /build/src/Storages/StorageReplicatedMergeTree.cpp:3872: DB::StorageReplicatedMergeTree::processQueueEntry(std::shared_ptr) @ 0x0000000015efc18a 23. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001624c1b2 24. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000162f9c70 25. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x00000000162fa55a 26. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc6653 27. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000000fccc4c3 28. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc3d92 29. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fcca080 30. ? @ 0x00007fbc6213eac3 31. ? @ 0x00007fbc621d0850 (version 25.3.6.10636.altinitytest (altinity build)) 2025.07.28 11:59:22.995211 [ 3961 ] {} test_13.rmt2 (7f9b740d-015c-470e-8cc6-8ba33be0dc63): auto DB::StorageReplicatedMergeTree::processQueueEntry(ReplicatedMergeTreeQueue::SelectedEntryPtr)::(anonymous class)::operator()(LogEntryPtr &) const: Code: 86. DB::HTTPException: Received error from remote server http://146b4357c08d:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Ftest%2F01165%2Ftest_13%2Frmt%2Freplicas%2F1&part=20250728_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.6.10636.altinitytest (altinity build)) '. (RECEIVED_ERROR_FROM_REMOTE_IO_SERVER), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.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 const&, int&&, String const&, unsigned long&&, String const&) @ 0x000000000feda8d9 4. /build/src/IO/HTTPCommon.cpp:104: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x000000000feda6e2 5. /build/src/IO/HTTPCommon.cpp:93: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x000000000feda537 6. /build/src/IO/ReadWriteBufferFromHTTP.cpp:277: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x000000001184a4c4 7. /build/src/IO/ReadWriteBufferFromHTTP.cpp:285: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x000000001184a615 8. /build/src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x000000001184ae59 9. /build/src/IO/ReadWriteBufferFromHTTP.cpp:472: void std::__function::__policy_invoker::__call_impl[abi:se190107]>(std::__function::__policy_storage const*) @ 0x000000001184cedd 10. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001184858b 11. /build/src/IO/ReadWriteBufferFromHTTP.cpp:465: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x000000001184bf0b 12. /build/src/IO/ReadBuffer.h:60: DB::ReadBuffer::next() @ 0x000000000a148c7b 13. /build/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) @ 0x0000000011849fb2 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]>&)>&, 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&) @ 0x0000000011841980 15. /build/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) @ 0x000000001621208e 16. /build/src/Storages/StorageReplicatedMergeTree.cpp:5228: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl[abi:se190107] const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000015f9a5fe 17. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000015ed8bfd 18. /build/src/Storages/StorageReplicatedMergeTree.cpp:2514: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x0000000015ec9aab 19. /build/src/Storages/StorageReplicatedMergeTree.cpp:2349: DB::StorageReplicatedMergeTree::executeLogEntry(DB::ReplicatedMergeTreeLogEntry&) @ 0x0000000015eba91b 20. /build/src/Storages/StorageReplicatedMergeTree.cpp:3876: bool std::__function::__policy_invoker&)>::__call_impl[abi:se190107])::$_1, bool (std::shared_ptr&)>>(std::__function::__policy_storage const*, std::shared_ptr&) @ 0x0000000015f9837e 21. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000165d6fc3 22. /build/src/Storages/StorageReplicatedMergeTree.cpp:3872: DB::StorageReplicatedMergeTree::processQueueEntry(std::shared_ptr) @ 0x0000000015efc18a 23. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001624c1b2 24. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000162f9c70 25. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x00000000162fa55a 26. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc6653 27. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000000fccc4c3 28. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc3d92 29. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fcca080 30. ? @ 0x00007fbc6213eac3 31. ? @ 0x00007fbc621d0850 (version 25.3.6.10636.altinitytest (altinity build)) 2025.07.28 11:59:23.422560 [ 3960 ] {} test_13.rmt2 (7f9b740d-015c-470e-8cc6-8ba33be0dc63): auto DB::StorageReplicatedMergeTree::processQueueEntry(ReplicatedMergeTreeQueue::SelectedEntryPtr)::(anonymous class)::operator()(LogEntryPtr &) const: Code: 86. DB::HTTPException: Received error from remote server http://146b4357c08d:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Ftest%2F01165%2Ftest_13%2Frmt%2Freplicas%2F1&part=20250728_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.6.10636.altinitytest (altinity build)) '. (RECEIVED_ERROR_FROM_REMOTE_IO_SERVER), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.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 const&, int&&, String const&, unsigned long&&, String const&) @ 0x000000000feda8d9 4. /build/src/IO/HTTPCommon.cpp:104: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x000000000feda6e2 5. /build/src/IO/HTTPCommon.cpp:93: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x000000000feda537 6. /build/src/IO/ReadWriteBufferFromHTTP.cpp:277: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x000000001184a4c4 7. /build/src/IO/ReadWriteBufferFromHTTP.cpp:285: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x000000001184a615 8. /build/src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x000000001184ae59 9. /build/src/IO/ReadWriteBufferFromHTTP.cpp:472: void std::__function::__policy_invoker::__call_impl[abi:se190107]>(std::__function::__policy_storage const*) @ 0x000000001184cedd 10. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001184858b 11. /build/src/IO/ReadWriteBufferFromHTTP.cpp:465: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x000000001184bf0b 12. /build/src/IO/ReadBuffer.h:60: DB::ReadBuffer::next() @ 0x000000000a148c7b 13. /build/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) @ 0x0000000011849fb2 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]>&)>&, 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&) @ 0x0000000011841980 15. /build/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) @ 0x000000001621208e 16. /build/src/Storages/StorageReplicatedMergeTree.cpp:5228: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl[abi:se190107] const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000015f9a5fe 17. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000015ed8bfd 18. /build/src/Storages/StorageReplicatedMergeTree.cpp:2514: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x0000000015ec9aab 19. /build/src/Storages/StorageReplicatedMergeTree.cpp:2349: DB::StorageReplicatedMergeTree::executeLogEntry(DB::ReplicatedMergeTreeLogEntry&) @ 0x0000000015eba91b 20. /build/src/Storages/StorageReplicatedMergeTree.cpp:3876: bool std::__function::__policy_invoker&)>::__call_impl[abi:se190107])::$_1, bool (std::shared_ptr&)>>(std::__function::__policy_storage const*, std::shared_ptr&) @ 0x0000000015f9837e 21. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000165d6fc3 22. /build/src/Storages/StorageReplicatedMergeTree.cpp:3872: DB::StorageReplicatedMergeTree::processQueueEntry(std::shared_ptr) @ 0x0000000015efc18a 23. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001624c1b2 24. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000162f9c70 25. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x00000000162fa55a 26. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc6653 27. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000000fccc4c3 28. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc3d92 29. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fcca080 30. ? @ 0x00007fbc6213eac3 31. ? @ 0x00007fbc621d0850 (version 25.3.6.10636.altinitytest (altinity build)) 2025.07.28 11:59:23.446273 [ 17306 ] {} 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. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception>&, String>(int, FormatStringHelperImpl>&>::type, std::type_identity::type>, std::basic_string_view>&, String&&) @ 0x000000001385a5eb 4. /build/src/Access/SettingsConstraints.cpp:376: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000013859b18 5. /build/src/Access/SettingsConstraints.cpp:300: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000013858faf 6. /build/src/Access/SettingsConstraints.cpp:209: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000013859223 7. /build/src/Interpreters/Context.cpp:2690: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000014436134 8. /build/src/Interpreters/Context.cpp:2729: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x000000001443662b 9. /build/src/Server/HTTPHandler.cpp:457: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000001686d165 10. /build/src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x0000000016870807 11. /build/src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x0000000016907e99 12. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 13. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 14. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 15. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 16. ? @ 0x00007fbc6213eac3 17. ? @ 0x00007fbc621d0850 (version 25.3.6.10636.altinitytest (altinity build)) 2025.07.28 11:59:23.826664 [ 3967 ] {} test_13.rmt2 (7f9b740d-015c-470e-8cc6-8ba33be0dc63): auto DB::StorageReplicatedMergeTree::processQueueEntry(ReplicatedMergeTreeQueue::SelectedEntryPtr)::(anonymous class)::operator()(LogEntryPtr &) const: Code: 86. DB::HTTPException: Received error from remote server http://146b4357c08d:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Ftest%2F01165%2Ftest_13%2Frmt%2Freplicas%2F1&part=20250728_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.6.10636.altinitytest (altinity build)) '. (RECEIVED_ERROR_FROM_REMOTE_IO_SERVER), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.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 const&, int&&, String const&, unsigned long&&, String const&) @ 0x000000000feda8d9 4. /build/src/IO/HTTPCommon.cpp:104: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x000000000feda6e2 5. /build/src/IO/HTTPCommon.cpp:93: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x000000000feda537 6. /build/src/IO/ReadWriteBufferFromHTTP.cpp:277: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x000000001184a4c4 7. /build/src/IO/ReadWriteBufferFromHTTP.cpp:285: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x000000001184a615 8. /build/src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x000000001184ae59 9. /build/src/IO/ReadWriteBufferFromHTTP.cpp:472: void std::__function::__policy_invoker::__call_impl[abi:se190107]>(std::__function::__policy_storage const*) @ 0x000000001184cedd 10. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001184858b 11. /build/src/IO/ReadWriteBufferFromHTTP.cpp:465: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x000000001184bf0b 12. /build/src/IO/ReadBuffer.h:60: DB::ReadBuffer::next() @ 0x000000000a148c7b 13. /build/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) @ 0x0000000011849fb2 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]>&)>&, 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&) @ 0x0000000011841980 15. /build/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) @ 0x000000001621208e 16. /build/src/Storages/StorageReplicatedMergeTree.cpp:5228: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl[abi:se190107] const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000015f9a5fe 17. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000015ed8bfd 18. /build/src/Storages/StorageReplicatedMergeTree.cpp:2514: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x0000000015ec9aab 19. /build/src/Storages/StorageReplicatedMergeTree.cpp:2349: DB::StorageReplicatedMergeTree::executeLogEntry(DB::ReplicatedMergeTreeLogEntry&) @ 0x0000000015eba91b 20. /build/src/Storages/StorageReplicatedMergeTree.cpp:3876: bool std::__function::__policy_invoker&)>::__call_impl[abi:se190107])::$_1, bool (std::shared_ptr&)>>(std::__function::__policy_storage const*, std::shared_ptr&) @ 0x0000000015f9837e 21. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000165d6fc3 22. /build/src/Storages/StorageReplicatedMergeTree.cpp:3872: DB::StorageReplicatedMergeTree::processQueueEntry(std::shared_ptr) @ 0x0000000015efc18a 23. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001624c1b2 24. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000162f9c70 25. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x00000000162fa55a 26. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc6653 27. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000000fccc4c3 28. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc3d92 29. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fcca080 30. ? @ 0x00007fbc6213eac3 31. ? @ 0x00007fbc621d0850 (version 25.3.6.10636.altinitytest (altinity build)) 2025.07.28 11:59:24.124912 [ 3968 ] {} test_13.rmt2 (7f9b740d-015c-470e-8cc6-8ba33be0dc63): auto DB::StorageReplicatedMergeTree::processQueueEntry(ReplicatedMergeTreeQueue::SelectedEntryPtr)::(anonymous class)::operator()(LogEntryPtr &) const: Code: 86. DB::HTTPException: Received error from remote server http://146b4357c08d:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Ftest%2F01165%2Ftest_13%2Frmt%2Freplicas%2F1&part=20250728_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.6.10636.altinitytest (altinity build)) '. (RECEIVED_ERROR_FROM_REMOTE_IO_SERVER), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.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 const&, int&&, String const&, unsigned long&&, String const&) @ 0x000000000feda8d9 4. /build/src/IO/HTTPCommon.cpp:104: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x000000000feda6e2 5. /build/src/IO/HTTPCommon.cpp:93: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x000000000feda537 6. /build/src/IO/ReadWriteBufferFromHTTP.cpp:277: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x000000001184a4c4 7. /build/src/IO/ReadWriteBufferFromHTTP.cpp:285: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x000000001184a615 8. /build/src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x000000001184ae59 9. /build/src/IO/ReadWriteBufferFromHTTP.cpp:472: void std::__function::__policy_invoker::__call_impl[abi:se190107]>(std::__function::__policy_storage const*) @ 0x000000001184cedd 10. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001184858b 11. /build/src/IO/ReadWriteBufferFromHTTP.cpp:465: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x000000001184bf0b 12. /build/src/IO/ReadBuffer.h:60: DB::ReadBuffer::next() @ 0x000000000a148c7b 13. /build/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) @ 0x0000000011849fb2 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]>&)>&, 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&) @ 0x0000000011841980 15. /build/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) @ 0x000000001621208e 16. /build/src/Storages/StorageReplicatedMergeTree.cpp:5228: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl[abi:se190107] const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000015f9a5fe 17. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000015ed8bfd 18. /build/src/Storages/StorageReplicatedMergeTree.cpp:2514: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x0000000015ec9aab 19. /build/src/Storages/StorageReplicatedMergeTree.cpp:2349: DB::StorageReplicatedMergeTree::executeLogEntry(DB::ReplicatedMergeTreeLogEntry&) @ 0x0000000015eba91b 20. /build/src/Storages/StorageReplicatedMergeTree.cpp:3876: bool std::__function::__policy_invoker&)>::__call_impl[abi:se190107])::$_1, bool (std::shared_ptr&)>>(std::__function::__policy_storage const*, std::shared_ptr&) @ 0x0000000015f9837e 21. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000165d6fc3 22. /build/src/Storages/StorageReplicatedMergeTree.cpp:3872: DB::StorageReplicatedMergeTree::processQueueEntry(std::shared_ptr) @ 0x0000000015efc18a 23. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001624c1b2 24. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000162f9c70 25. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x00000000162fa55a 26. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc6653 27. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000000fccc4c3 28. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc3d92 29. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fcca080 30. ? @ 0x00007fbc6213eac3 31. ? @ 0x00007fbc621d0850 (version 25.3.6.10636.altinitytest (altinity build)) 2025.07.28 11:59:24.469263 [ 4581 ] {250d46a4-46bb-4369-aa95-55b1d194afff} executeQuery: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=37, jobs=10): While executing MergeTreeSelect(pool: ReadPoolInOrder, algorithm: InOrder). (CANNOT_SCHEDULE_TASK) (version 25.3.6.10636.altinitytest (altinity build)) (from [::1]:51050) (comment: 03237_insert_sparse_columns_mem.sh) (query 2, line 3) (in query: SELECT sum(sipHash64(*)) FROM t_insert_mem;), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000fccaeeb 4. /build/src/Common/ThreadPool.cpp:275: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000fccc813 5. /build/src/Common/ThreadPool.cpp:323: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fcc7bbc 6. /build/src/Common/ThreadPool.cpp:494: ThreadPoolImpl>::scheduleOrThrowOnError(std::function, Priority) @ 0x000000000fcc7a0e 7. /build/src/Common/threadPoolCallbackRunner.h:52: std::future> std::__function::__policy_invoker> (DB::MergeTreeMarksLoader::loadMarksAsync()::$_0&&, Priority)>::__call_impl[abi:se190107]> (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&&) @ 0x0000000016474731 8. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000016471940 9. /build/src/Storages/MergeTree/MergeTreeMarksLoader.cpp:83: DB::MergeTreeMarksLoader::startAsyncLoad() @ 0x000000001647173f 10. /build/src/Storages/MergeTree/MergeTreeReaderWide.cpp:294: DB::MergeTreeReaderWide::addStream(DB::ISerialization::SubstreamPath const&, String const&) @ 0x00000000164aa163 11. /build/src/Storages/MergeTree/MergeTreeReaderWide.cpp:251: void std::__function::__policy_invoker::__call_impl[abi:se190107] const&)::$_0, void (DB::ISerialization::SubstreamPath const&)>>(std::__function::__policy_storage const*, DB::ISerialization::SubstreamPath const&) @ 0x00000000164ab3ce 12. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000013d0fe68 13. /build/src/DataTypes/Serializations/ISerialization.cpp:104: DB::ISerialization::enumerateStreams(std::function const&, std::shared_ptr const&, COW::immutable_ptr const&) const @ 0x0000000013c7acfd 14. /build/src/Storages/MergeTree/MergeTreeReaderWide.cpp:255: DB::MergeTreeReaderWide::addStreams(DB::NameAndTypePair const&, std::shared_ptr const&) @ 0x00000000164a83c4 15. /build/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) @ 0x00000000164a81cc 16. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]&, 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&&) @ 0x00000000163cf0e0 17. /build/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 @ 0x00000000163ca51e 18. /build/src/Storages/MergeTree/MergeTreeReadTask.cpp:60: DB::MergeTreeReadTask::createReaders(std::shared_ptr const&, DB::MergeTreeReadTask::Extras const&, DB::MarkRanges const&) @ 0x00000000164b5386 19. /build/src/Storages/MergeTree/MergeTreeReadPoolBase.cpp:274: DB::MergeTreeReadPoolBase::createTask(std::shared_ptr, DB::MarkRanges, DB::MergeTreeReadTask*) const @ 0x0000000016e53b1f 20. /build/src/Storages/MergeTree/MergeTreeReadPoolInOrder.cpp:74: DB::MergeTreeReadPoolInOrder::getTask(unsigned long, DB::MergeTreeReadTask*) @ 0x0000000016e7808a 21. /build/src/Storages/MergeTree/MergeTreeSelectProcessor.cpp:191: DB::MergeTreeSelectProcessor::read() @ 0x00000000164c0b40 22. /build/src/Storages/MergeTree/MergeTreeSource.cpp:229: DB::MergeTreeSource::tryGenerate() @ 0x0000000016e43d69 23. /build/src/Processors/ISource.cpp:108: DB::ISource::work() @ 0x00000000169a21e7 24. /build/src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x00000000169bd00f 25. /build/src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x00000000169b2105 26. /build/src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeSingleThread(unsigned long) @ 0x00000000169b23be 27. /build/src/Processors/Executors/PipelineExecutor.cpp:416: void std::__function::__policy_invoker::__call_impl[abi:se190107]>(std::__function::__policy_storage const*) @ 0x00000000169b2e3f 28. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc6653 29. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000000fccc4c3 30. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc3d92 31. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fcca080 2025.07.28 11:59:24.581408 [ 3960 ] {} test_13.rmt2 (7f9b740d-015c-470e-8cc6-8ba33be0dc63): auto DB::StorageReplicatedMergeTree::processQueueEntry(ReplicatedMergeTreeQueue::SelectedEntryPtr)::(anonymous class)::operator()(LogEntryPtr &) const: Code: 86. DB::HTTPException: Received error from remote server http://146b4357c08d:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Ftest%2F01165%2Ftest_13%2Frmt%2Freplicas%2F1&part=20250728_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.6.10636.altinitytest (altinity build)) '. (RECEIVED_ERROR_FROM_REMOTE_IO_SERVER), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.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 const&, int&&, String const&, unsigned long&&, String const&) @ 0x000000000feda8d9 4. /build/src/IO/HTTPCommon.cpp:104: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x000000000feda6e2 5. /build/src/IO/HTTPCommon.cpp:93: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x000000000feda537 6. /build/src/IO/ReadWriteBufferFromHTTP.cpp:277: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x000000001184a4c4 7. /build/src/IO/ReadWriteBufferFromHTTP.cpp:285: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x000000001184a615 8. /build/src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x000000001184ae59 9. /build/src/IO/ReadWriteBufferFromHTTP.cpp:472: void std::__function::__policy_invoker::__call_impl[abi:se190107]>(std::__function::__policy_storage const*) @ 0x000000001184cedd 10. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001184858b 11. /build/src/IO/ReadWriteBufferFromHTTP.cpp:465: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x000000001184bf0b 12. /build/src/IO/ReadBuffer.h:60: DB::ReadBuffer::next() @ 0x000000000a148c7b 13. /build/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) @ 0x0000000011849fb2 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]>&)>&, 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&) @ 0x0000000011841980 15. /build/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) @ 0x000000001621208e 16. /build/src/Storages/StorageReplicatedMergeTree.cpp:5228: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl[abi:se190107] const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000015f9a5fe 17. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000015ed8bfd 18. /build/src/Storages/StorageReplicatedMergeTree.cpp:2514: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x0000000015ec9aab 19. /build/src/Storages/StorageReplicatedMergeTree.cpp:2349: DB::StorageReplicatedMergeTree::executeLogEntry(DB::ReplicatedMergeTreeLogEntry&) @ 0x0000000015eba91b 20. /build/src/Storages/StorageReplicatedMergeTree.cpp:3876: bool std::__function::__policy_invoker&)>::__call_impl[abi:se190107])::$_1, bool (std::shared_ptr&)>>(std::__function::__policy_storage const*, std::shared_ptr&) @ 0x0000000015f9837e 21. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000165d6fc3 22. /build/src/Storages/StorageReplicatedMergeTree.cpp:3872: DB::StorageReplicatedMergeTree::processQueueEntry(std::shared_ptr) @ 0x0000000015efc18a 23. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001624c1b2 24. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000162f9c70 25. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x00000000162fa55a 26. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc6653 27. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000000fccc4c3 28. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc3d92 29. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fcca080 30. ? @ 0x00007fbc6213eac3 31. ? @ 0x00007fbc621d0850 (version 25.3.6.10636.altinitytest (altinity build)) 2025.07.28 11:59:24.704598 [ 17306 ] {} 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. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception>&, String>(int, FormatStringHelperImpl>&>::type, std::type_identity::type>, std::basic_string_view>&, String&&) @ 0x000000001385a5eb 4. /build/src/Access/SettingsConstraints.cpp:376: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000013859b18 5. /build/src/Access/SettingsConstraints.cpp:300: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000013858faf 6. /build/src/Access/SettingsConstraints.cpp:209: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000013859223 7. /build/src/Interpreters/Context.cpp:2690: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000014436134 8. /build/src/Interpreters/Context.cpp:2729: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x000000001443662b 9. /build/src/Server/HTTPHandler.cpp:457: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000001686d165 10. /build/src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x0000000016870807 11. /build/src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x0000000016907e99 12. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 13. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 14. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 15. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 16. ? @ 0x00007fbc6213eac3 17. ? @ 0x00007fbc621d0850 (version 25.3.6.10636.altinitytest (altinity build)) 2025.07.28 11:59:25.257852 [ 3961 ] {} test_13.rmt2 (7f9b740d-015c-470e-8cc6-8ba33be0dc63): auto DB::StorageReplicatedMergeTree::processQueueEntry(ReplicatedMergeTreeQueue::SelectedEntryPtr)::(anonymous class)::operator()(LogEntryPtr &) const: Code: 86. DB::HTTPException: Received error from remote server http://146b4357c08d:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Ftest%2F01165%2Ftest_13%2Frmt%2Freplicas%2F1&part=20250728_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.6.10636.altinitytest (altinity build)) '. (RECEIVED_ERROR_FROM_REMOTE_IO_SERVER), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.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 const&, int&&, String const&, unsigned long&&, String const&) @ 0x000000000feda8d9 4. /build/src/IO/HTTPCommon.cpp:104: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x000000000feda6e2 5. /build/src/IO/HTTPCommon.cpp:93: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x000000000feda537 6. /build/src/IO/ReadWriteBufferFromHTTP.cpp:277: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x000000001184a4c4 7. /build/src/IO/ReadWriteBufferFromHTTP.cpp:285: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x000000001184a615 8. /build/src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x000000001184ae59 9. /build/src/IO/ReadWriteBufferFromHTTP.cpp:472: void std::__function::__policy_invoker::__call_impl[abi:se190107]>(std::__function::__policy_storage const*) @ 0x000000001184cedd 10. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001184858b 11. /build/src/IO/ReadWriteBufferFromHTTP.cpp:465: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x000000001184bf0b 12. /build/src/IO/ReadBuffer.h:60: DB::ReadBuffer::next() @ 0x000000000a148c7b 13. /build/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) @ 0x0000000011849fb2 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]>&)>&, 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&) @ 0x0000000011841980 15. /build/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) @ 0x000000001621208e 16. /build/src/Storages/StorageReplicatedMergeTree.cpp:5228: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl[abi:se190107] const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000015f9a5fe 17. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000015ed8bfd 18. /build/src/Storages/StorageReplicatedMergeTree.cpp:2514: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x0000000015ec9aab 19. /build/src/Storages/StorageReplicatedMergeTree.cpp:2349: DB::StorageReplicatedMergeTree::executeLogEntry(DB::ReplicatedMergeTreeLogEntry&) @ 0x0000000015eba91b 20. /build/src/Storages/StorageReplicatedMergeTree.cpp:3876: bool std::__function::__policy_invoker&)>::__call_impl[abi:se190107])::$_1, bool (std::shared_ptr&)>>(std::__function::__policy_storage const*, std::shared_ptr&) @ 0x0000000015f9837e 21. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000165d6fc3 22. /build/src/Storages/StorageReplicatedMergeTree.cpp:3872: DB::StorageReplicatedMergeTree::processQueueEntry(std::shared_ptr) @ 0x0000000015efc18a 23. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001624c1b2 24. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000162f9c70 25. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x00000000162fa55a 26. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc6653 27. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000000fccc4c3 28. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc3d92 29. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fcca080 30. ? @ 0x00007fbc6213eac3 31. ? @ 0x00007fbc621d0850 (version 25.3.6.10636.altinitytest (altinity build)) 2025.07.28 11:59:25.434811 [ 4581 ] {} TCPHandler: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=37, jobs=10): While executing MergeTreeSelect(pool: ReadPoolInOrder, algorithm: InOrder). (CANNOT_SCHEDULE_TASK), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000fccaeeb 4. /build/src/Common/ThreadPool.cpp:275: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000fccc813 5. /build/src/Common/ThreadPool.cpp:323: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fcc7bbc 6. /build/src/Common/ThreadPool.cpp:494: ThreadPoolImpl>::scheduleOrThrowOnError(std::function, Priority) @ 0x000000000fcc7a0e 7. /build/src/Common/threadPoolCallbackRunner.h:52: std::future> std::__function::__policy_invoker> (DB::MergeTreeMarksLoader::loadMarksAsync()::$_0&&, Priority)>::__call_impl[abi:se190107]> (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&&) @ 0x0000000016474731 8. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000016471940 9. /build/src/Storages/MergeTree/MergeTreeMarksLoader.cpp:83: DB::MergeTreeMarksLoader::startAsyncLoad() @ 0x000000001647173f 10. /build/src/Storages/MergeTree/MergeTreeReaderWide.cpp:294: DB::MergeTreeReaderWide::addStream(DB::ISerialization::SubstreamPath const&, String const&) @ 0x00000000164aa163 11. /build/src/Storages/MergeTree/MergeTreeReaderWide.cpp:251: void std::__function::__policy_invoker::__call_impl[abi:se190107] const&)::$_0, void (DB::ISerialization::SubstreamPath const&)>>(std::__function::__policy_storage const*, DB::ISerialization::SubstreamPath const&) @ 0x00000000164ab3ce 12. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000013d0fe68 13. /build/src/DataTypes/Serializations/ISerialization.cpp:104: DB::ISerialization::enumerateStreams(std::function const&, std::shared_ptr const&, COW::immutable_ptr const&) const @ 0x0000000013c7acfd 14. /build/src/Storages/MergeTree/MergeTreeReaderWide.cpp:255: DB::MergeTreeReaderWide::addStreams(DB::NameAndTypePair const&, std::shared_ptr const&) @ 0x00000000164a83c4 15. /build/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) @ 0x00000000164a81cc 16. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]&, 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&&) @ 0x00000000163cf0e0 17. /build/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 @ 0x00000000163ca51e 18. /build/src/Storages/MergeTree/MergeTreeReadTask.cpp:60: DB::MergeTreeReadTask::createReaders(std::shared_ptr const&, DB::MergeTreeReadTask::Extras const&, DB::MarkRanges const&) @ 0x00000000164b5386 19. /build/src/Storages/MergeTree/MergeTreeReadPoolBase.cpp:274: DB::MergeTreeReadPoolBase::createTask(std::shared_ptr, DB::MarkRanges, DB::MergeTreeReadTask*) const @ 0x0000000016e53b1f 20. /build/src/Storages/MergeTree/MergeTreeReadPoolInOrder.cpp:74: DB::MergeTreeReadPoolInOrder::getTask(unsigned long, DB::MergeTreeReadTask*) @ 0x0000000016e7808a 21. /build/src/Storages/MergeTree/MergeTreeSelectProcessor.cpp:191: DB::MergeTreeSelectProcessor::read() @ 0x00000000164c0b40 22. /build/src/Storages/MergeTree/MergeTreeSource.cpp:229: DB::MergeTreeSource::tryGenerate() @ 0x0000000016e43d69 23. /build/src/Processors/ISource.cpp:108: DB::ISource::work() @ 0x00000000169a21e7 24. /build/src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x00000000169bd00f 25. /build/src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x00000000169b2105 26. /build/src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeSingleThread(unsigned long) @ 0x00000000169b23be 27. /build/src/Processors/Executors/PipelineExecutor.cpp:416: void std::__function::__policy_invoker::__call_impl[abi:se190107]>(std::__function::__policy_storage const*) @ 0x00000000169b2e3f 28. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc6653 29. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000000fccc4c3 30. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc3d92 31. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fcca080 Job's origin stack trace: 0. /build/src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000000fc33b84 1. /build/src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000000fcc2ea7 2. /build/src/Common/ThreadPool.cpp:401: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fcc7f1c 3. /build/src/Common/ThreadPool.cpp:494: ThreadPoolImpl>::scheduleOrThrowOnError(std::function, Priority) @ 0x000000000fcc7a0e 4. /build/src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::spawnThreadsImpl() @ 0x00000000169b2c0c 5. /build/src/Processors/Executors/PipelineExecutor.cpp:394: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x00000000169b0ba7 6. /build/src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x00000000169b03f4 7. /build/src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:se190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169bfeab 8. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc3d92 9. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fcca080 10. ? @ 0x00007fbc6213eac3 11. ? @ 0x00007fbc621d0850 Job's origin stack trace: 0. /build/src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000000fc33b84 1. /build/src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000000fcc2ea7 2. /build/src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fcc535c 3. /build/src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000000fcc584d 4. /build/src/Common/ThreadPool.h:279: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x00000000169bf193 5. /build/src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x00000000169bf518 6. /build/src/Server/TCPHandler.cpp:1237: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x00000000168f1525 7. /build/src/Server/TCPHandler.cpp:678: DB::TCPHandler::runImpl() @ 0x00000000168e68e5 8. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 9. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 10. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 11. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 12. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 13. ? @ 0x00007fbc6213eac3 14. ? @ 0x00007fbc621d0850 2025.07.28 11:59:26.072930 [ 3962 ] {} test_13.rmt2 (7f9b740d-015c-470e-8cc6-8ba33be0dc63): auto DB::StorageReplicatedMergeTree::processQueueEntry(ReplicatedMergeTreeQueue::SelectedEntryPtr)::(anonymous class)::operator()(LogEntryPtr &) const: Code: 86. DB::HTTPException: Received error from remote server http://146b4357c08d:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Ftest%2F01165%2Ftest_13%2Frmt%2Freplicas%2F1&part=20250728_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.6.10636.altinitytest (altinity build)) '. (RECEIVED_ERROR_FROM_REMOTE_IO_SERVER), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.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 const&, int&&, String const&, unsigned long&&, String const&) @ 0x000000000feda8d9 4. /build/src/IO/HTTPCommon.cpp:104: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x000000000feda6e2 5. /build/src/IO/HTTPCommon.cpp:93: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x000000000feda537 6. /build/src/IO/ReadWriteBufferFromHTTP.cpp:277: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x000000001184a4c4 7. /build/src/IO/ReadWriteBufferFromHTTP.cpp:285: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x000000001184a615 8. /build/src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x000000001184ae59 9. /build/src/IO/ReadWriteBufferFromHTTP.cpp:472: void std::__function::__policy_invoker::__call_impl[abi:se190107]>(std::__function::__policy_storage const*) @ 0x000000001184cedd 10. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001184858b 11. /build/src/IO/ReadWriteBufferFromHTTP.cpp:465: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x000000001184bf0b 12. /build/src/IO/ReadBuffer.h:60: DB::ReadBuffer::next() @ 0x000000000a148c7b 13. /build/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) @ 0x0000000011849fb2 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]>&)>&, 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&) @ 0x0000000011841980 15. /build/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) @ 0x000000001621208e 16. /build/src/Storages/StorageReplicatedMergeTree.cpp:5228: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl[abi:se190107] const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000015f9a5fe 17. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000015ed8bfd 18. /build/src/Storages/StorageReplicatedMergeTree.cpp:2514: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x0000000015ec9aab 19. /build/src/Storages/StorageReplicatedMergeTree.cpp:2349: DB::StorageReplicatedMergeTree::executeLogEntry(DB::ReplicatedMergeTreeLogEntry&) @ 0x0000000015eba91b 20. /build/src/Storages/StorageReplicatedMergeTree.cpp:3876: bool std::__function::__policy_invoker&)>::__call_impl[abi:se190107])::$_1, bool (std::shared_ptr&)>>(std::__function::__policy_storage const*, std::shared_ptr&) @ 0x0000000015f9837e 21. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000165d6fc3 22. /build/src/Storages/StorageReplicatedMergeTree.cpp:3872: DB::StorageReplicatedMergeTree::processQueueEntry(std::shared_ptr) @ 0x0000000015efc18a 23. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001624c1b2 24. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000162f9c70 25. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x00000000162fa55a 26. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc6653 27. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000000fccc4c3 28. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc3d92 29. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fcca080 30. ? @ 0x00007fbc6213eac3 31. ? @ 0x00007fbc621d0850 (version 25.3.6.10636.altinitytest (altinity build)) 2025.07.28 11:59:26.612495 [ 3964 ] {} test_13.rmt2 (7f9b740d-015c-470e-8cc6-8ba33be0dc63): auto DB::StorageReplicatedMergeTree::processQueueEntry(ReplicatedMergeTreeQueue::SelectedEntryPtr)::(anonymous class)::operator()(LogEntryPtr &) const: Code: 86. DB::HTTPException: Received error from remote server http://146b4357c08d:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Ftest%2F01165%2Ftest_13%2Frmt%2Freplicas%2F1&part=20250728_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.6.10636.altinitytest (altinity build)) '. (RECEIVED_ERROR_FROM_REMOTE_IO_SERVER), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.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 const&, int&&, String const&, unsigned long&&, String const&) @ 0x000000000feda8d9 4. /build/src/IO/HTTPCommon.cpp:104: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x000000000feda6e2 5. /build/src/IO/HTTPCommon.cpp:93: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x000000000feda537 6. /build/src/IO/ReadWriteBufferFromHTTP.cpp:277: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x000000001184a4c4 7. /build/src/IO/ReadWriteBufferFromHTTP.cpp:285: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x000000001184a615 8. /build/src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x000000001184ae59 9. /build/src/IO/ReadWriteBufferFromHTTP.cpp:472: void std::__function::__policy_invoker::__call_impl[abi:se190107]>(std::__function::__policy_storage const*) @ 0x000000001184cedd 10. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001184858b 11. /build/src/IO/ReadWriteBufferFromHTTP.cpp:465: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x000000001184bf0b 12. /build/src/IO/ReadBuffer.h:60: DB::ReadBuffer::next() @ 0x000000000a148c7b 13. /build/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) @ 0x0000000011849fb2 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]>&)>&, 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&) @ 0x0000000011841980 15. /build/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) @ 0x000000001621208e 16. /build/src/Storages/StorageReplicatedMergeTree.cpp:5228: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl[abi:se190107] const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000015f9a5fe 17. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000015ed8bfd 18. /build/src/Storages/StorageReplicatedMergeTree.cpp:2514: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x0000000015ec9aab 19. /build/src/Storages/StorageReplicatedMergeTree.cpp:2349: DB::StorageReplicatedMergeTree::executeLogEntry(DB::ReplicatedMergeTreeLogEntry&) @ 0x0000000015eba91b 20. /build/src/Storages/StorageReplicatedMergeTree.cpp:3876: bool std::__function::__policy_invoker&)>::__call_impl[abi:se190107])::$_1, bool (std::shared_ptr&)>>(std::__function::__policy_storage const*, std::shared_ptr&) @ 0x0000000015f9837e 21. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000165d6fc3 22. /build/src/Storages/StorageReplicatedMergeTree.cpp:3872: DB::StorageReplicatedMergeTree::processQueueEntry(std::shared_ptr) @ 0x0000000015efc18a 23. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001624c1b2 24. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000162f9c70 25. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x00000000162fa55a 26. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc6653 27. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000000fccc4c3 28. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc3d92 29. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fcca080 30. ? @ 0x00007fbc6213eac3 31. ? @ 0x00007fbc621d0850 (version 25.3.6.10636.altinitytest (altinity build)) 2025.07.28 11:59:27.489619 [ 17557 ] {ccbc8734-6523-4cdd-8816-cba98a961a05} executeQuery: Code: 452. DB::Exception: Setting allow_experimental_object_type should not be changed. (SETTING_CONSTRAINT_VIOLATION) (version 25.3.6.10636.altinitytest (altinity build)) (from [::1]:47360) (comment: 02246_flatten_tuple.sql) (query 7, line 14) (in query: SET allow_experimental_object_type = 1;), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x000000000c25bc4b 4. /build/src/Access/SettingsConstraints.cpp:343: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000138596e3 5. /build/src/Access/SettingsConstraints.cpp:300: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000013858faf 6. /build/src/Access/SettingsConstraints.cpp:194: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges const&, DB::SettingSource) const @ 0x00000000138591b3 7. /build/src/Interpreters/Context.cpp:2722: DB::Context::checkSettingsConstraints(DB::SettingsChanges const&, DB::SettingSource) @ 0x0000000014436509 8. /build/src/Interpreters/InterpreterSetQuery.cpp:28: DB::InterpreterSetQuery::execute() @ 0x00000000149e240a 9. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88dc9 10. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 11. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 12. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 13. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 14. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 16. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 17. ? @ 0x00007fbc6213eac3 18. ? @ 0x00007fbc621d0850 2025.07.28 11:59:27.509202 [ 17557 ] {} 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. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x000000000c25bc4b 4. /build/src/Access/SettingsConstraints.cpp:343: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000138596e3 5. /build/src/Access/SettingsConstraints.cpp:300: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000013858faf 6. /build/src/Access/SettingsConstraints.cpp:194: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges const&, DB::SettingSource) const @ 0x00000000138591b3 7. /build/src/Interpreters/Context.cpp:2722: DB::Context::checkSettingsConstraints(DB::SettingsChanges const&, DB::SettingSource) @ 0x0000000014436509 8. /build/src/Interpreters/InterpreterSetQuery.cpp:28: DB::InterpreterSetQuery::execute() @ 0x00000000149e240a 9. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88dc9 10. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 11. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 12. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 13. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 14. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 16. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 17. ? @ 0x00007fbc6213eac3 18. ? @ 0x00007fbc621d0850 2025.07.28 11:59:27.675860 [ 3966 ] {} test_13.rmt2 (7f9b740d-015c-470e-8cc6-8ba33be0dc63): auto DB::StorageReplicatedMergeTree::processQueueEntry(ReplicatedMergeTreeQueue::SelectedEntryPtr)::(anonymous class)::operator()(LogEntryPtr &) const: Code: 86. DB::HTTPException: Received error from remote server http://146b4357c08d:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Ftest%2F01165%2Ftest_13%2Frmt%2Freplicas%2F1&part=20250728_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.6.10636.altinitytest (altinity build)) '. (RECEIVED_ERROR_FROM_REMOTE_IO_SERVER), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.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 const&, int&&, String const&, unsigned long&&, String const&) @ 0x000000000feda8d9 4. /build/src/IO/HTTPCommon.cpp:104: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x000000000feda6e2 5. /build/src/IO/HTTPCommon.cpp:93: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x000000000feda537 6. /build/src/IO/ReadWriteBufferFromHTTP.cpp:277: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x000000001184a4c4 7. /build/src/IO/ReadWriteBufferFromHTTP.cpp:285: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x000000001184a615 8. /build/src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x000000001184ae59 9. /build/src/IO/ReadWriteBufferFromHTTP.cpp:472: void std::__function::__policy_invoker::__call_impl[abi:se190107]>(std::__function::__policy_storage const*) @ 0x000000001184cedd 10. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001184858b 11. /build/src/IO/ReadWriteBufferFromHTTP.cpp:465: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x000000001184bf0b 12. /build/src/IO/ReadBuffer.h:60: DB::ReadBuffer::next() @ 0x000000000a148c7b 13. /build/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) @ 0x0000000011849fb2 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]>&)>&, 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&) @ 0x0000000011841980 15. /build/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) @ 0x000000001621208e 16. /build/src/Storages/StorageReplicatedMergeTree.cpp:5228: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl[abi:se190107] const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000015f9a5fe 17. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000015ed8bfd 18. /build/src/Storages/StorageReplicatedMergeTree.cpp:2514: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x0000000015ec9aab 19. /build/src/Storages/StorageReplicatedMergeTree.cpp:2349: DB::StorageReplicatedMergeTree::executeLogEntry(DB::ReplicatedMergeTreeLogEntry&) @ 0x0000000015eba91b 20. /build/src/Storages/StorageReplicatedMergeTree.cpp:3876: bool std::__function::__policy_invoker&)>::__call_impl[abi:se190107])::$_1, bool (std::shared_ptr&)>>(std::__function::__policy_storage const*, std::shared_ptr&) @ 0x0000000015f9837e 21. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000165d6fc3 22. /build/src/Storages/StorageReplicatedMergeTree.cpp:3872: DB::StorageReplicatedMergeTree::processQueueEntry(std::shared_ptr) @ 0x0000000015efc18a 23. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001624c1b2 24. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000162f9c70 25. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x00000000162fa55a 26. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc6653 27. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000000fccc4c3 28. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc3d92 29. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fcca080 30. ? @ 0x00007fbc6213eac3 31. ? @ 0x00007fbc621d0850 (version 25.3.6.10636.altinitytest (altinity build)) 2025.07.28 11:59:28.096803 [ 11851 ] {2d1fe0d5-7e9c-4a5e-8eb7-a8802a15ac2e} executeQuery: Code: 219. DB::Exception: New table appeared in database being dropped or detached. Try again. (DATABASE_NOT_EMPTY) (version 25.3.6.10636.altinitytest (altinity build)) (from [::1]:36402) (comment: 02791_final_block_structure_mismatch_bug.sql) (in query: DROP DATABASE IF EXISTS test_t9pol0d3 SYNC ), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000000a074fcb 4. /build/src/Interpreters/DatabaseCatalog.cpp:608: DB::DatabaseCatalog::detachDatabase(std::shared_ptr, String const&, bool, bool) @ 0x00000000144f41b9 5. /build/src/Interpreters/InterpreterDropQuery.cpp:482: DB::InterpreterDropQuery::executeToDatabaseImpl(DB::ASTDropQuery const&, std::shared_ptr&, std::vector, DB::UUIDTag>, std::allocator, DB::UUIDTag>>>&) @ 0x00000000149179be 6. /build/src/Interpreters/InterpreterDropQuery.cpp:363: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x0000000014913988 7. /build/src/Interpreters/InterpreterDropQuery.cpp:99: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000014913142 8. /build/src/Interpreters/InterpreterDropQuery.cpp:72: DB::InterpreterDropQuery::execute() @ 0x0000000014912b65 9. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88dc9 10. /build/src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x0000000014c8ca7b 11. /build/src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000001686da12 12. /build/src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x0000000016870807 13. /build/src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x0000000016907e99 14. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 15. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 16. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 17. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 18. ? @ 0x00007fbc6213eac3 19. ? @ 0x00007fbc621d0850 2025.07.28 11:59:28.098420 [ 11851 ] {2d1fe0d5-7e9c-4a5e-8eb7-a8802a15ac2e} 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. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000000a074fcb 4. /build/src/Interpreters/DatabaseCatalog.cpp:608: DB::DatabaseCatalog::detachDatabase(std::shared_ptr, String const&, bool, bool) @ 0x00000000144f41b9 5. /build/src/Interpreters/InterpreterDropQuery.cpp:482: DB::InterpreterDropQuery::executeToDatabaseImpl(DB::ASTDropQuery const&, std::shared_ptr&, std::vector, DB::UUIDTag>, std::allocator, DB::UUIDTag>>>&) @ 0x00000000149179be 6. /build/src/Interpreters/InterpreterDropQuery.cpp:363: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x0000000014913988 7. /build/src/Interpreters/InterpreterDropQuery.cpp:99: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000014913142 8. /build/src/Interpreters/InterpreterDropQuery.cpp:72: DB::InterpreterDropQuery::execute() @ 0x0000000014912b65 9. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88dc9 10. /build/src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x0000000014c8ca7b 11. /build/src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000001686da12 12. /build/src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x0000000016870807 13. /build/src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x0000000016907e99 14. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 15. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 16. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 17. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 18. ? @ 0x00007fbc6213eac3 19. ? @ 0x00007fbc621d0850 (version 25.3.6.10636.altinitytest (altinity build)) 2025.07.28 11:59:28.779418 [ 3972 ] {} test_13.rmt2 (7f9b740d-015c-470e-8cc6-8ba33be0dc63): auto DB::StorageReplicatedMergeTree::processQueueEntry(ReplicatedMergeTreeQueue::SelectedEntryPtr)::(anonymous class)::operator()(LogEntryPtr &) const: Code: 86. DB::HTTPException: Received error from remote server http://146b4357c08d:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Ftest%2F01165%2Ftest_13%2Frmt%2Freplicas%2F1&part=20250728_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.6.10636.altinitytest (altinity build)) '. (RECEIVED_ERROR_FROM_REMOTE_IO_SERVER), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.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 const&, int&&, String const&, unsigned long&&, String const&) @ 0x000000000feda8d9 4. /build/src/IO/HTTPCommon.cpp:104: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x000000000feda6e2 5. /build/src/IO/HTTPCommon.cpp:93: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x000000000feda537 6. /build/src/IO/ReadWriteBufferFromHTTP.cpp:277: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x000000001184a4c4 7. /build/src/IO/ReadWriteBufferFromHTTP.cpp:285: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x000000001184a615 8. /build/src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x000000001184ae59 9. /build/src/IO/ReadWriteBufferFromHTTP.cpp:472: void std::__function::__policy_invoker::__call_impl[abi:se190107]>(std::__function::__policy_storage const*) @ 0x000000001184cedd 10. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001184858b 11. /build/src/IO/ReadWriteBufferFromHTTP.cpp:465: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x000000001184bf0b 12. /build/src/IO/ReadBuffer.h:60: DB::ReadBuffer::next() @ 0x000000000a148c7b 13. /build/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) @ 0x0000000011849fb2 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]>&)>&, 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&) @ 0x0000000011841980 15. /build/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) @ 0x000000001621208e 16. /build/src/Storages/StorageReplicatedMergeTree.cpp:5228: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl[abi:se190107] const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000015f9a5fe 17. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000015ed8bfd 18. /build/src/Storages/StorageReplicatedMergeTree.cpp:2514: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x0000000015ec9aab 19. /build/src/Storages/StorageReplicatedMergeTree.cpp:2349: DB::StorageReplicatedMergeTree::executeLogEntry(DB::ReplicatedMergeTreeLogEntry&) @ 0x0000000015eba91b 20. /build/src/Storages/StorageReplicatedMergeTree.cpp:3876: bool std::__function::__policy_invoker&)>::__call_impl[abi:se190107])::$_1, bool (std::shared_ptr&)>>(std::__function::__policy_storage const*, std::shared_ptr&) @ 0x0000000015f9837e 21. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000165d6fc3 22. /build/src/Storages/StorageReplicatedMergeTree.cpp:3872: DB::StorageReplicatedMergeTree::processQueueEntry(std::shared_ptr) @ 0x0000000015efc18a 23. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001624c1b2 24. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000162f9c70 25. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x00000000162fa55a 26. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc6653 27. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000000fccc4c3 28. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc3d92 29. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fcca080 30. ? @ 0x00007fbc6213eac3 31. ? @ 0x00007fbc621d0850 (version 25.3.6.10636.altinitytest (altinity build)) 2025.07.28 11:59:28.905988 [ 3968 ] {} test_13.rmt2 (7f9b740d-015c-470e-8cc6-8ba33be0dc63): auto DB::StorageReplicatedMergeTree::processQueueEntry(ReplicatedMergeTreeQueue::SelectedEntryPtr)::(anonymous class)::operator()(LogEntryPtr &) const: Code: 86. DB::HTTPException: Received error from remote server http://146b4357c08d:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Ftest%2F01165%2Ftest_13%2Frmt%2Freplicas%2F1&part=20250728_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.6.10636.altinitytest (altinity build)) '. (RECEIVED_ERROR_FROM_REMOTE_IO_SERVER), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.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 const&, int&&, String const&, unsigned long&&, String const&) @ 0x000000000feda8d9 4. /build/src/IO/HTTPCommon.cpp:104: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x000000000feda6e2 5. /build/src/IO/HTTPCommon.cpp:93: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x000000000feda537 6. /build/src/IO/ReadWriteBufferFromHTTP.cpp:277: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x000000001184a4c4 7. /build/src/IO/ReadWriteBufferFromHTTP.cpp:285: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x000000001184a615 8. /build/src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x000000001184ae59 9. /build/src/IO/ReadWriteBufferFromHTTP.cpp:472: void std::__function::__policy_invoker::__call_impl[abi:se190107]>(std::__function::__policy_storage const*) @ 0x000000001184cedd 10. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001184858b 11. /build/src/IO/ReadWriteBufferFromHTTP.cpp:465: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x000000001184bf0b 12. /build/src/IO/ReadBuffer.h:60: DB::ReadBuffer::next() @ 0x000000000a148c7b 13. /build/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) @ 0x0000000011849fb2 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]>&)>&, 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&) @ 0x0000000011841980 15. /build/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) @ 0x000000001621208e 16. /build/src/Storages/StorageReplicatedMergeTree.cpp:5228: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl[abi:se190107] const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000015f9a5fe 17. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000015ed8bfd 18. /build/src/Storages/StorageReplicatedMergeTree.cpp:2514: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x0000000015ec9aab 19. /build/src/Storages/StorageReplicatedMergeTree.cpp:2349: DB::StorageReplicatedMergeTree::executeLogEntry(DB::ReplicatedMergeTreeLogEntry&) @ 0x0000000015eba91b 20. /build/src/Storages/StorageReplicatedMergeTree.cpp:3876: bool std::__function::__policy_invoker&)>::__call_impl[abi:se190107])::$_1, bool (std::shared_ptr&)>>(std::__function::__policy_storage const*, std::shared_ptr&) @ 0x0000000015f9837e 21. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000165d6fc3 22. /build/src/Storages/StorageReplicatedMergeTree.cpp:3872: DB::StorageReplicatedMergeTree::processQueueEntry(std::shared_ptr) @ 0x0000000015efc18a 23. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001624c1b2 24. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000162f9c70 25. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x00000000162fa55a 26. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc6653 27. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000000fccc4c3 28. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc3d92 29. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fcca080 30. ? @ 0x00007fbc6213eac3 31. ? @ 0x00007fbc621d0850 (version 25.3.6.10636.altinitytest (altinity build)) 2025.07.28 11:59:29.237727 [ 3977 ] {} test_13.rmt2 (7f9b740d-015c-470e-8cc6-8ba33be0dc63): auto DB::StorageReplicatedMergeTree::processQueueEntry(ReplicatedMergeTreeQueue::SelectedEntryPtr)::(anonymous class)::operator()(LogEntryPtr &) const: Code: 86. DB::HTTPException: Received error from remote server http://146b4357c08d:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Ftest%2F01165%2Ftest_13%2Frmt%2Freplicas%2F1&part=20250728_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.6.10636.altinitytest (altinity build)) '. (RECEIVED_ERROR_FROM_REMOTE_IO_SERVER), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.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 const&, int&&, String const&, unsigned long&&, String const&) @ 0x000000000feda8d9 4. /build/src/IO/HTTPCommon.cpp:104: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x000000000feda6e2 5. /build/src/IO/HTTPCommon.cpp:93: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x000000000feda537 6. /build/src/IO/ReadWriteBufferFromHTTP.cpp:277: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x000000001184a4c4 7. /build/src/IO/ReadWriteBufferFromHTTP.cpp:285: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x000000001184a615 8. /build/src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x000000001184ae59 9. /build/src/IO/ReadWriteBufferFromHTTP.cpp:472: void std::__function::__policy_invoker::__call_impl[abi:se190107]>(std::__function::__policy_storage const*) @ 0x000000001184cedd 10. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001184858b 11. /build/src/IO/ReadWriteBufferFromHTTP.cpp:465: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x000000001184bf0b 12. /build/src/IO/ReadBuffer.h:60: DB::ReadBuffer::next() @ 0x000000000a148c7b 13. /build/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) @ 0x0000000011849fb2 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]>&)>&, 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&) @ 0x0000000011841980 15. /build/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) @ 0x000000001621208e 16. /build/src/Storages/StorageReplicatedMergeTree.cpp:5228: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl[abi:se190107] const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000015f9a5fe 17. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000015ed8bfd 18. /build/src/Storages/StorageReplicatedMergeTree.cpp:2514: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x0000000015ec9aab 19. /build/src/Storages/StorageReplicatedMergeTree.cpp:2349: DB::StorageReplicatedMergeTree::executeLogEntry(DB::ReplicatedMergeTreeLogEntry&) @ 0x0000000015eba91b 20. /build/src/Storages/StorageReplicatedMergeTree.cpp:3876: bool std::__function::__policy_invoker&)>::__call_impl[abi:se190107])::$_1, bool (std::shared_ptr&)>>(std::__function::__policy_storage const*, std::shared_ptr&) @ 0x0000000015f9837e 21. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000165d6fc3 22. /build/src/Storages/StorageReplicatedMergeTree.cpp:3872: DB::StorageReplicatedMergeTree::processQueueEntry(std::shared_ptr) @ 0x0000000015efc18a 23. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001624c1b2 24. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000162f9c70 25. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x00000000162fa55a 26. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc6653 27. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000000fccc4c3 28. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc3d92 29. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fcca080 30. ? @ 0x00007fbc6213eac3 31. ? @ 0x00007fbc621d0850 (version 25.3.6.10636.altinitytest (altinity build)) 2025.07.28 11:59:29.466472 [ 3971 ] {} test_13.rmt2 (7f9b740d-015c-470e-8cc6-8ba33be0dc63): auto DB::StorageReplicatedMergeTree::processQueueEntry(ReplicatedMergeTreeQueue::SelectedEntryPtr)::(anonymous class)::operator()(LogEntryPtr &) const: Code: 86. DB::HTTPException: Received error from remote server http://146b4357c08d:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Ftest%2F01165%2Ftest_13%2Frmt%2Freplicas%2F1&part=20250728_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.6.10636.altinitytest (altinity build)) '. (RECEIVED_ERROR_FROM_REMOTE_IO_SERVER), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.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 const&, int&&, String const&, unsigned long&&, String const&) @ 0x000000000feda8d9 4. /build/src/IO/HTTPCommon.cpp:104: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x000000000feda6e2 5. /build/src/IO/HTTPCommon.cpp:93: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x000000000feda537 6. /build/src/IO/ReadWriteBufferFromHTTP.cpp:277: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x000000001184a4c4 7. /build/src/IO/ReadWriteBufferFromHTTP.cpp:285: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x000000001184a615 8. /build/src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x000000001184ae59 9. /build/src/IO/ReadWriteBufferFromHTTP.cpp:472: void std::__function::__policy_invoker::__call_impl[abi:se190107]>(std::__function::__policy_storage const*) @ 0x000000001184cedd 10. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001184858b 11. /build/src/IO/ReadWriteBufferFromHTTP.cpp:465: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x000000001184bf0b 12. /build/src/IO/ReadBuffer.h:60: DB::ReadBuffer::next() @ 0x000000000a148c7b 13. /build/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) @ 0x0000000011849fb2 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]>&)>&, 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&) @ 0x0000000011841980 15. /build/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) @ 0x000000001621208e 16. /build/src/Storages/StorageReplicatedMergeTree.cpp:5228: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl[abi:se190107] const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000015f9a5fe 17. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000015ed8bfd 18. /build/src/Storages/StorageReplicatedMergeTree.cpp:2514: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x0000000015ec9aab 19. /build/src/Storages/StorageReplicatedMergeTree.cpp:2349: DB::StorageReplicatedMergeTree::executeLogEntry(DB::ReplicatedMergeTreeLogEntry&) @ 0x0000000015eba91b 20. /build/src/Storages/StorageReplicatedMergeTree.cpp:3876: bool std::__function::__policy_invoker&)>::__call_impl[abi:se190107])::$_1, bool (std::shared_ptr&)>>(std::__function::__policy_storage const*, std::shared_ptr&) @ 0x0000000015f9837e 21. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000165d6fc3 22. /build/src/Storages/StorageReplicatedMergeTree.cpp:3872: DB::StorageReplicatedMergeTree::processQueueEntry(std::shared_ptr) @ 0x0000000015efc18a 23. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001624c1b2 24. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000162f9c70 25. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x00000000162fa55a 26. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc6653 27. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000000fccc4c3 28. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc3d92 29. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fcca080 30. ? @ 0x00007fbc6213eac3 31. ? @ 0x00007fbc621d0850 (version 25.3.6.10636.altinitytest (altinity build)) 2025.07.28 11:59:29.840454 [ 3965 ] {} test_13.rmt2 (7f9b740d-015c-470e-8cc6-8ba33be0dc63): auto DB::StorageReplicatedMergeTree::processQueueEntry(ReplicatedMergeTreeQueue::SelectedEntryPtr)::(anonymous class)::operator()(LogEntryPtr &) const: Code: 86. DB::HTTPException: Received error from remote server http://146b4357c08d:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Ftest%2F01165%2Ftest_13%2Frmt%2Freplicas%2F1&part=20250728_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.6.10636.altinitytest (altinity build)) '. (RECEIVED_ERROR_FROM_REMOTE_IO_SERVER), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.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 const&, int&&, String const&, unsigned long&&, String const&) @ 0x000000000feda8d9 4. /build/src/IO/HTTPCommon.cpp:104: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x000000000feda6e2 5. /build/src/IO/HTTPCommon.cpp:93: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x000000000feda537 6. /build/src/IO/ReadWriteBufferFromHTTP.cpp:277: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x000000001184a4c4 7. /build/src/IO/ReadWriteBufferFromHTTP.cpp:285: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x000000001184a615 8. /build/src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x000000001184ae59 9. /build/src/IO/ReadWriteBufferFromHTTP.cpp:472: void std::__function::__policy_invoker::__call_impl[abi:se190107]>(std::__function::__policy_storage const*) @ 0x000000001184cedd 10. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001184858b 11. /build/src/IO/ReadWriteBufferFromHTTP.cpp:465: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x000000001184bf0b 12. /build/src/IO/ReadBuffer.h:60: DB::ReadBuffer::next() @ 0x000000000a148c7b 13. /build/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) @ 0x0000000011849fb2 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]>&)>&, 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&) @ 0x0000000011841980 15. /build/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) @ 0x000000001621208e 16. /build/src/Storages/StorageReplicatedMergeTree.cpp:5228: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl[abi:se190107] const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000015f9a5fe 17. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000015ed8bfd 18. /build/src/Storages/StorageReplicatedMergeTree.cpp:2514: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x0000000015ec9aab 19. /build/src/Storages/StorageReplicatedMergeTree.cpp:2349: DB::StorageReplicatedMergeTree::executeLogEntry(DB::ReplicatedMergeTreeLogEntry&) @ 0x0000000015eba91b 20. /build/src/Storages/StorageReplicatedMergeTree.cpp:3876: bool std::__function::__policy_invoker&)>::__call_impl[abi:se190107])::$_1, bool (std::shared_ptr&)>>(std::__function::__policy_storage const*, std::shared_ptr&) @ 0x0000000015f9837e 21. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000165d6fc3 22. /build/src/Storages/StorageReplicatedMergeTree.cpp:3872: DB::StorageReplicatedMergeTree::processQueueEntry(std::shared_ptr) @ 0x0000000015efc18a 23. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001624c1b2 24. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000162f9c70 25. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x00000000162fa55a 26. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc6653 27. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000000fccc4c3 28. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc3d92 29. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fcca080 30. ? @ 0x00007fbc6213eac3 31. ? @ 0x00007fbc621d0850 (version 25.3.6.10636.altinitytest (altinity build)) 2025.07.28 11:59:29.986964 [ 17611 ] {} 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. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception>&, String>(int, FormatStringHelperImpl>&>::type, std::type_identity::type>, std::basic_string_view>&, String&&) @ 0x000000001385a5eb 4. /build/src/Access/SettingsConstraints.cpp:376: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000013859b18 5. /build/src/Access/SettingsConstraints.cpp:300: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000013858faf 6. /build/src/Access/SettingsConstraints.cpp:209: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000013859223 7. /build/src/Interpreters/Context.cpp:2690: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000014436134 8. /build/src/Interpreters/Context.cpp:2729: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x000000001443662b 9. /build/src/Server/HTTPHandler.cpp:457: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000001686d165 10. /build/src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x0000000016870807 11. /build/src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x0000000016907e99 12. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 13. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 14. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 15. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 16. ? @ 0x00007fbc6213eac3 17. ? @ 0x00007fbc621d0850 (version 25.3.6.10636.altinitytest (altinity build)) 2025.07.28 11:59:30.409212 [ 17207 ] {2ba62c13-3dd4-4b5f-8db3-9d93722a36a5} executeQuery: Code: 36. DB::Exception: The nested column of first argument in function mapFromArrays must not contain NULLs: In scope SELECT mapFromArrays([toLowCardinality(toNullable(1)), toLowCardinality(CAST(NULL, 'Nullable(Int32)'))], [3, 4]) GROUP BY 1. (BAD_ARGUMENTS) (version 25.3.6.10636.altinitytest (altinity build)) (from [::1]:47386) (comment: 03399_lc_nullable_mapfromarrays.sql) (query 6, line 16) (in query: SELECT mapFromArrays( [toLowCardinality(toNullable(1)), toLowCardinality(cast(NULL as Nullable(Int32)))], [3, 4] ) GROUP BY 1;), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x000000000a06b56b 4. /build/src/Functions/map.cpp:249: DB::(anonymous namespace)::FunctionMapFromArrays::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000cf86609 5. /build/src/Functions/IFunction.h:437: DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000a069f2a 6. /build/src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000012d9965a 7. /build/src/Functions/IFunction.cpp:351: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d93b02 8. /build/src/Functions/IFunction.cpp:177: DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d93698 9. /build/src/Functions/IFunction.cpp:343: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d93aad 10. /build/src/Functions/IFunction.cpp:424: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d94e1b 11. /build/src/Functions/IFunction.cpp:498: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d95c72 12. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3567: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000014034494 13. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3838: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000014019a9e 14. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3980: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000014018e31 15. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:4304: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000014042fa7 16. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5605: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000014013749 17. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000140127f9 18. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000014011fce 19. /build/src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000001406ce8a 20. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000014973b42 21. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000001497268d 22. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000014974d24 23. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001492924b 24. /build/src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88641 25. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 26. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 27. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 28. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 29. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 30. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 31. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 2025.07.28 11:59:30.431421 [ 17207 ] {} TCPHandler: Code: 36. DB::Exception: The nested column of first argument in function mapFromArrays must not contain NULLs: In scope SELECT mapFromArrays([toLowCardinality(toNullable(1)), toLowCardinality(CAST(NULL, 'Nullable(Int32)'))], [3, 4]) GROUP BY 1. (BAD_ARGUMENTS), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x000000000a06b56b 4. /build/src/Functions/map.cpp:249: DB::(anonymous namespace)::FunctionMapFromArrays::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000cf86609 5. /build/src/Functions/IFunction.h:437: DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000a069f2a 6. /build/src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000012d9965a 7. /build/src/Functions/IFunction.cpp:351: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d93b02 8. /build/src/Functions/IFunction.cpp:177: DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d93698 9. /build/src/Functions/IFunction.cpp:343: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d93aad 10. /build/src/Functions/IFunction.cpp:424: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d94e1b 11. /build/src/Functions/IFunction.cpp:498: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d95c72 12. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3567: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000014034494 13. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3838: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000014019a9e 14. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3980: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000014018e31 15. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:4304: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000014042fa7 16. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5605: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000014013749 17. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000140127f9 18. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000014011fce 19. /build/src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000001406ce8a 20. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000014973b42 21. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000001497268d 22. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000014974d24 23. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001492924b 24. /build/src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88641 25. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 26. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 27. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 28. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 29. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 30. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 31. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 2025.07.28 11:59:30.525364 [ 17207 ] {4c53b212-de50-42ce-9f5e-9717a8fb4d38} executeQuery: Code: 36. DB::Exception: The nested column of first argument in function mapFromArrays must not contain NULLs: In scope SELECT mapFromArrays([toLowCardinality(toNullable('x')), toLowCardinality(CAST(NULL, 'Nullable(String)'))], [3, 4]) GROUP BY 1. (BAD_ARGUMENTS) (version 25.3.6.10636.altinitytest (altinity build)) (from [::1]:47386) (comment: 03399_lc_nullable_mapfromarrays.sql) (query 7, line 21) (in query: SELECT mapFromArrays( [toLowCardinality(toNullable('x')), toLowCardinality(cast(NULL as Nullable(String)))], [3, 4] ) GROUP BY 1;), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x000000000a06b56b 4. /build/src/Functions/map.cpp:249: DB::(anonymous namespace)::FunctionMapFromArrays::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000cf86609 5. /build/src/Functions/IFunction.h:437: DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000a069f2a 6. /build/src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000012d9965a 7. /build/src/Functions/IFunction.cpp:351: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d93b02 8. /build/src/Functions/IFunction.cpp:177: DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d93698 9. /build/src/Functions/IFunction.cpp:343: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d93aad 10. /build/src/Functions/IFunction.cpp:424: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d94e1b 11. /build/src/Functions/IFunction.cpp:498: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d95c72 12. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3567: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000014034494 13. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3838: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000014019a9e 14. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3980: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000014018e31 15. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:4304: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000014042fa7 16. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5605: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000014013749 17. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000140127f9 18. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000014011fce 19. /build/src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000001406ce8a 20. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000014973b42 21. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000001497268d 22. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000014974d24 23. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001492924b 24. /build/src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88641 25. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 26. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 27. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 28. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 29. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 30. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 31. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 2025.07.28 11:59:30.530028 [ 17207 ] {} TCPHandler: Code: 36. DB::Exception: The nested column of first argument in function mapFromArrays must not contain NULLs: In scope SELECT mapFromArrays([toLowCardinality(toNullable('x')), toLowCardinality(CAST(NULL, 'Nullable(String)'))], [3, 4]) GROUP BY 1. (BAD_ARGUMENTS), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x000000000a06b56b 4. /build/src/Functions/map.cpp:249: DB::(anonymous namespace)::FunctionMapFromArrays::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000cf86609 5. /build/src/Functions/IFunction.h:437: DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000a069f2a 6. /build/src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000012d9965a 7. /build/src/Functions/IFunction.cpp:351: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d93b02 8. /build/src/Functions/IFunction.cpp:177: DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d93698 9. /build/src/Functions/IFunction.cpp:343: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d93aad 10. /build/src/Functions/IFunction.cpp:424: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d94e1b 11. /build/src/Functions/IFunction.cpp:498: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d95c72 12. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3567: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000014034494 13. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3838: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000014019a9e 14. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3980: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000014018e31 15. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:4304: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000014042fa7 16. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5605: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000014013749 17. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000140127f9 18. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000014011fce 19. /build/src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000001406ce8a 20. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000014973b42 21. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000001497268d 22. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000014974d24 23. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001492924b 24. /build/src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88641 25. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 26. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 27. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 28. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 29. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 30. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 31. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 2025.07.28 11:59:30.751185 [ 3964 ] {} test_13.rmt2 (7f9b740d-015c-470e-8cc6-8ba33be0dc63): auto DB::StorageReplicatedMergeTree::processQueueEntry(ReplicatedMergeTreeQueue::SelectedEntryPtr)::(anonymous class)::operator()(LogEntryPtr &) const: Code: 86. DB::HTTPException: Received error from remote server http://146b4357c08d:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Ftest%2F01165%2Ftest_13%2Frmt%2Freplicas%2F1&part=20250728_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.6.10636.altinitytest (altinity build)) '. (RECEIVED_ERROR_FROM_REMOTE_IO_SERVER), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.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 const&, int&&, String const&, unsigned long&&, String const&) @ 0x000000000feda8d9 4. /build/src/IO/HTTPCommon.cpp:104: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x000000000feda6e2 5. /build/src/IO/HTTPCommon.cpp:93: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x000000000feda537 6. /build/src/IO/ReadWriteBufferFromHTTP.cpp:277: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x000000001184a4c4 7. /build/src/IO/ReadWriteBufferFromHTTP.cpp:285: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x000000001184a615 8. /build/src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x000000001184ae59 9. /build/src/IO/ReadWriteBufferFromHTTP.cpp:472: void std::__function::__policy_invoker::__call_impl[abi:se190107]>(std::__function::__policy_storage const*) @ 0x000000001184cedd 10. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001184858b 11. /build/src/IO/ReadWriteBufferFromHTTP.cpp:465: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x000000001184bf0b 12. /build/src/IO/ReadBuffer.h:60: DB::ReadBuffer::next() @ 0x000000000a148c7b 13. /build/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) @ 0x0000000011849fb2 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]>&)>&, 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&) @ 0x0000000011841980 15. /build/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) @ 0x000000001621208e 16. /build/src/Storages/StorageReplicatedMergeTree.cpp:5228: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl[abi:se190107] const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000015f9a5fe 17. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000015ed8bfd 18. /build/src/Storages/StorageReplicatedMergeTree.cpp:2514: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x0000000015ec9aab 19. /build/src/Storages/StorageReplicatedMergeTree.cpp:2349: DB::StorageReplicatedMergeTree::executeLogEntry(DB::ReplicatedMergeTreeLogEntry&) @ 0x0000000015eba91b 20. /build/src/Storages/StorageReplicatedMergeTree.cpp:3876: bool std::__function::__policy_invoker&)>::__call_impl[abi:se190107])::$_1, bool (std::shared_ptr&)>>(std::__function::__policy_storage const*, std::shared_ptr&) @ 0x0000000015f9837e 21. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000165d6fc3 22. /build/src/Storages/StorageReplicatedMergeTree.cpp:3872: DB::StorageReplicatedMergeTree::processQueueEntry(std::shared_ptr) @ 0x0000000015efc18a 23. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001624c1b2 24. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000162f9c70 25. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x00000000162fa55a 26. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc6653 27. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000000fccc4c3 28. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc3d92 29. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fcca080 30. ? @ 0x00007fbc6213eac3 31. ? @ 0x00007fbc621d0850 (version 25.3.6.10636.altinitytest (altinity build)) 2025.07.28 11:59:30.829876 [ 3972 ] {} test_13.rmt2 (7f9b740d-015c-470e-8cc6-8ba33be0dc63): auto DB::StorageReplicatedMergeTree::processQueueEntry(ReplicatedMergeTreeQueue::SelectedEntryPtr)::(anonymous class)::operator()(LogEntryPtr &) const: Code: 86. DB::HTTPException: Received error from remote server http://146b4357c08d:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Ftest%2F01165%2Ftest_13%2Frmt%2Freplicas%2F1&part=20250728_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.6.10636.altinitytest (altinity build)) '. (RECEIVED_ERROR_FROM_REMOTE_IO_SERVER), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.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 const&, int&&, String const&, unsigned long&&, String const&) @ 0x000000000feda8d9 4. /build/src/IO/HTTPCommon.cpp:104: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x000000000feda6e2 5. /build/src/IO/HTTPCommon.cpp:93: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x000000000feda537 6. /build/src/IO/ReadWriteBufferFromHTTP.cpp:277: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x000000001184a4c4 7. /build/src/IO/ReadWriteBufferFromHTTP.cpp:285: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x000000001184a615 8. /build/src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x000000001184ae59 9. /build/src/IO/ReadWriteBufferFromHTTP.cpp:472: void std::__function::__policy_invoker::__call_impl[abi:se190107]>(std::__function::__policy_storage const*) @ 0x000000001184cedd 10. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001184858b 11. /build/src/IO/ReadWriteBufferFromHTTP.cpp:465: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x000000001184bf0b 12. /build/src/IO/ReadBuffer.h:60: DB::ReadBuffer::next() @ 0x000000000a148c7b 13. /build/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) @ 0x0000000011849fb2 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]>&)>&, 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&) @ 0x0000000011841980 15. /build/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) @ 0x000000001621208e 16. /build/src/Storages/StorageReplicatedMergeTree.cpp:5228: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl[abi:se190107] const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000015f9a5fe 17. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000015ed8bfd 18. /build/src/Storages/StorageReplicatedMergeTree.cpp:2514: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x0000000015ec9aab 19. /build/src/Storages/StorageReplicatedMergeTree.cpp:2349: DB::StorageReplicatedMergeTree::executeLogEntry(DB::ReplicatedMergeTreeLogEntry&) @ 0x0000000015eba91b 20. /build/src/Storages/StorageReplicatedMergeTree.cpp:3876: bool std::__function::__policy_invoker&)>::__call_impl[abi:se190107])::$_1, bool (std::shared_ptr&)>>(std::__function::__policy_storage const*, std::shared_ptr&) @ 0x0000000015f9837e 21. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000165d6fc3 22. /build/src/Storages/StorageReplicatedMergeTree.cpp:3872: DB::StorageReplicatedMergeTree::processQueueEntry(std::shared_ptr) @ 0x0000000015efc18a 23. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001624c1b2 24. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000162f9c70 25. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x00000000162fa55a 26. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc6653 27. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000000fccc4c3 28. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc3d92 29. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fcca080 30. ? @ 0x00007fbc6213eac3 31. ? @ 0x00007fbc621d0850 (version 25.3.6.10636.altinitytest (altinity build)) 2025.07.28 11:59:31.143129 [ 3960 ] {} test_13.rmt2 (7f9b740d-015c-470e-8cc6-8ba33be0dc63): auto DB::StorageReplicatedMergeTree::processQueueEntry(ReplicatedMergeTreeQueue::SelectedEntryPtr)::(anonymous class)::operator()(LogEntryPtr &) const: Code: 86. DB::HTTPException: Received error from remote server http://146b4357c08d:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Ftest%2F01165%2Ftest_13%2Frmt%2Freplicas%2F1&part=20250728_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.6.10636.altinitytest (altinity build)) '. (RECEIVED_ERROR_FROM_REMOTE_IO_SERVER), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.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 const&, int&&, String const&, unsigned long&&, String const&) @ 0x000000000feda8d9 4. /build/src/IO/HTTPCommon.cpp:104: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x000000000feda6e2 5. /build/src/IO/HTTPCommon.cpp:93: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x000000000feda537 6. /build/src/IO/ReadWriteBufferFromHTTP.cpp:277: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x000000001184a4c4 7. /build/src/IO/ReadWriteBufferFromHTTP.cpp:285: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x000000001184a615 8. /build/src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x000000001184ae59 9. /build/src/IO/ReadWriteBufferFromHTTP.cpp:472: void std::__function::__policy_invoker::__call_impl[abi:se190107]>(std::__function::__policy_storage const*) @ 0x000000001184cedd 10. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001184858b 11. /build/src/IO/ReadWriteBufferFromHTTP.cpp:465: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x000000001184bf0b 12. /build/src/IO/ReadBuffer.h:60: DB::ReadBuffer::next() @ 0x000000000a148c7b 13. /build/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) @ 0x0000000011849fb2 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]>&)>&, 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&) @ 0x0000000011841980 15. /build/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) @ 0x000000001621208e 16. /build/src/Storages/StorageReplicatedMergeTree.cpp:5228: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl[abi:se190107] const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000015f9a5fe 17. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000015ed8bfd 18. /build/src/Storages/StorageReplicatedMergeTree.cpp:2514: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x0000000015ec9aab 19. /build/src/Storages/StorageReplicatedMergeTree.cpp:2349: DB::StorageReplicatedMergeTree::executeLogEntry(DB::ReplicatedMergeTreeLogEntry&) @ 0x0000000015eba91b 20. /build/src/Storages/StorageReplicatedMergeTree.cpp:3876: bool std::__function::__policy_invoker&)>::__call_impl[abi:se190107])::$_1, bool (std::shared_ptr&)>>(std::__function::__policy_storage const*, std::shared_ptr&) @ 0x0000000015f9837e 21. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000165d6fc3 22. /build/src/Storages/StorageReplicatedMergeTree.cpp:3872: DB::StorageReplicatedMergeTree::processQueueEntry(std::shared_ptr) @ 0x0000000015efc18a 23. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001624c1b2 24. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000162f9c70 25. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x00000000162fa55a 26. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc6653 27. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000000fccc4c3 28. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc3d92 29. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fcca080 30. ? @ 0x00007fbc6213eac3 31. ? @ 0x00007fbc621d0850 (version 25.3.6.10636.altinitytest (altinity build)) 2025.07.28 11:59:31.950341 [ 3965 ] {} test_13.rmt2 (7f9b740d-015c-470e-8cc6-8ba33be0dc63): auto DB::StorageReplicatedMergeTree::processQueueEntry(ReplicatedMergeTreeQueue::SelectedEntryPtr)::(anonymous class)::operator()(LogEntryPtr &) const: Code: 86. DB::HTTPException: Received error from remote server http://146b4357c08d:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Ftest%2F01165%2Ftest_13%2Frmt%2Freplicas%2F1&part=20250728_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.6.10636.altinitytest (altinity build)) '. (RECEIVED_ERROR_FROM_REMOTE_IO_SERVER), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.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 const&, int&&, String const&, unsigned long&&, String const&) @ 0x000000000feda8d9 4. /build/src/IO/HTTPCommon.cpp:104: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x000000000feda6e2 5. /build/src/IO/HTTPCommon.cpp:93: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x000000000feda537 6. /build/src/IO/ReadWriteBufferFromHTTP.cpp:277: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x000000001184a4c4 7. /build/src/IO/ReadWriteBufferFromHTTP.cpp:285: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x000000001184a615 8. /build/src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x000000001184ae59 9. /build/src/IO/ReadWriteBufferFromHTTP.cpp:472: void std::__function::__policy_invoker::__call_impl[abi:se190107]>(std::__function::__policy_storage const*) @ 0x000000001184cedd 10. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001184858b 11. /build/src/IO/ReadWriteBufferFromHTTP.cpp:465: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x000000001184bf0b 12. /build/src/IO/ReadBuffer.h:60: DB::ReadBuffer::next() @ 0x000000000a148c7b 13. /build/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) @ 0x0000000011849fb2 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]>&)>&, 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&) @ 0x0000000011841980 15. /build/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) @ 0x000000001621208e 16. /build/src/Storages/StorageReplicatedMergeTree.cpp:5228: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl[abi:se190107] const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000015f9a5fe 17. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000015ed8bfd 18. /build/src/Storages/StorageReplicatedMergeTree.cpp:2514: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x0000000015ec9aab 19. /build/src/Storages/StorageReplicatedMergeTree.cpp:2349: DB::StorageReplicatedMergeTree::executeLogEntry(DB::ReplicatedMergeTreeLogEntry&) @ 0x0000000015eba91b 20. /build/src/Storages/StorageReplicatedMergeTree.cpp:3876: bool std::__function::__policy_invoker&)>::__call_impl[abi:se190107])::$_1, bool (std::shared_ptr&)>>(std::__function::__policy_storage const*, std::shared_ptr&) @ 0x0000000015f9837e 21. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000165d6fc3 22. /build/src/Storages/StorageReplicatedMergeTree.cpp:3872: DB::StorageReplicatedMergeTree::processQueueEntry(std::shared_ptr) @ 0x0000000015efc18a 23. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001624c1b2 24. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000162f9c70 25. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x00000000162fa55a 26. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc6653 27. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000000fccc4c3 28. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc3d92 29. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fcca080 30. ? @ 0x00007fbc6213eac3 31. ? @ 0x00007fbc621d0850 (version 25.3.6.10636.altinitytest (altinity build)) 2025.07.28 11:59:32.150131 [ 3963 ] {} test_13.rmt2 (7f9b740d-015c-470e-8cc6-8ba33be0dc63): auto DB::StorageReplicatedMergeTree::processQueueEntry(ReplicatedMergeTreeQueue::SelectedEntryPtr)::(anonymous class)::operator()(LogEntryPtr &) const: Code: 86. DB::HTTPException: Received error from remote server http://146b4357c08d:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Ftest%2F01165%2Ftest_13%2Frmt%2Freplicas%2F1&part=20250728_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.6.10636.altinitytest (altinity build)) '. (RECEIVED_ERROR_FROM_REMOTE_IO_SERVER), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.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 const&, int&&, String const&, unsigned long&&, String const&) @ 0x000000000feda8d9 4. /build/src/IO/HTTPCommon.cpp:104: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x000000000feda6e2 5. /build/src/IO/HTTPCommon.cpp:93: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x000000000feda537 6. /build/src/IO/ReadWriteBufferFromHTTP.cpp:277: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x000000001184a4c4 7. /build/src/IO/ReadWriteBufferFromHTTP.cpp:285: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x000000001184a615 8. /build/src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x000000001184ae59 9. /build/src/IO/ReadWriteBufferFromHTTP.cpp:472: void std::__function::__policy_invoker::__call_impl[abi:se190107]>(std::__function::__policy_storage const*) @ 0x000000001184cedd 10. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001184858b 11. /build/src/IO/ReadWriteBufferFromHTTP.cpp:465: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x000000001184bf0b 12. /build/src/IO/ReadBuffer.h:60: DB::ReadBuffer::next() @ 0x000000000a148c7b 13. /build/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) @ 0x0000000011849fb2 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]>&)>&, 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&) @ 0x0000000011841980 15. /build/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) @ 0x000000001621208e 16. /build/src/Storages/StorageReplicatedMergeTree.cpp:5228: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl[abi:se190107] const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000015f9a5fe 17. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000015ed8bfd 18. /build/src/Storages/StorageReplicatedMergeTree.cpp:2514: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x0000000015ec9aab 19. /build/src/Storages/StorageReplicatedMergeTree.cpp:2349: DB::StorageReplicatedMergeTree::executeLogEntry(DB::ReplicatedMergeTreeLogEntry&) @ 0x0000000015eba91b 20. /build/src/Storages/StorageReplicatedMergeTree.cpp:3876: bool std::__function::__policy_invoker&)>::__call_impl[abi:se190107])::$_1, bool (std::shared_ptr&)>>(std::__function::__policy_storage const*, std::shared_ptr&) @ 0x0000000015f9837e 21. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000165d6fc3 22. /build/src/Storages/StorageReplicatedMergeTree.cpp:3872: DB::StorageReplicatedMergeTree::processQueueEntry(std::shared_ptr) @ 0x0000000015efc18a 23. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001624c1b2 24. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000162f9c70 25. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x00000000162fa55a 26. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc6653 27. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000000fccc4c3 28. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc3d92 29. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fcca080 30. ? @ 0x00007fbc6213eac3 31. ? @ 0x00007fbc621d0850 (version 25.3.6.10636.altinitytest (altinity build)) 2025.07.28 11:59:32.159524 [ 17207 ] {c1285f62-2624-457e-b60c-62271acffea8} executeQuery: Code: 36. DB::Exception: The nested column of first argument in function mapFromArrays must not contain NULLs: while executing 'FUNCTION mapFromArrays(__table1.k :: 2, __table1.v :: 0) -> mapFromArrays(__table1.k, __table1.v) Map(LowCardinality(Int32), Int32) : 1'. (BAD_ARGUMENTS) (version 25.3.6.10636.altinitytest (altinity build)) (from [::1]:47386) (comment: 03399_lc_nullable_mapfromarrays.sql) (query 18, line 55) (in query: SELECT mapFromArrays(k, v) FROM 03399_lc_nullable_int_mixed;), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x000000000a06b56b 4. /build/src/Functions/map.cpp:249: DB::(anonymous namespace)::FunctionMapFromArrays::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000cf86609 5. /build/src/Functions/IFunctionAdaptors.cpp:10: DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000012d995fa 6. /build/src/Functions/IFunction.cpp:353: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d93b52 7. /build/src/Functions/IFunction.cpp:424: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d94e1b 8. /build/src/Functions/IFunction.cpp:498: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d95c72 9. /build/src/Interpreters/ExpressionActions.cpp:636: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x00000000145176f3 10. /build/src/Processors/Transforms/ExpressionTransform.cpp:25: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x0000000016c0b34c 11. /build/src/Processors/ISimpleTransform.h:33: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000011a9a453 12. /build/src/Processors/ISimpleTransform.cpp:89: DB::ISimpleTransform::work() @ 0x000000001699fca0 13. /build/src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x00000000169bd00f 14. /build/src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x00000000169b2105 15. /build/src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeSingleThread(unsigned long) @ 0x00000000169b23be 16. /build/src/Processors/Executors/PipelineExecutor.cpp:454: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x00000000169b0be7 17. /build/src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x00000000169b03f4 18. /build/src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:se190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169bfeab 19. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc3d92 20. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fcca080 21. ? @ 0x00007fbc6213eac3 22. ? @ 0x00007fbc621d0850 2025.07.28 11:59:32.164427 [ 17207 ] {} TCPHandler: Code: 36. DB::Exception: The nested column of first argument in function mapFromArrays must not contain NULLs: while executing 'FUNCTION mapFromArrays(__table1.k :: 2, __table1.v :: 0) -> mapFromArrays(__table1.k, __table1.v) Map(LowCardinality(Int32), Int32) : 1'. (BAD_ARGUMENTS), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x000000000a06b56b 4. /build/src/Functions/map.cpp:249: DB::(anonymous namespace)::FunctionMapFromArrays::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000cf86609 5. /build/src/Functions/IFunctionAdaptors.cpp:10: DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000012d995fa 6. /build/src/Functions/IFunction.cpp:353: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d93b52 7. /build/src/Functions/IFunction.cpp:424: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d94e1b 8. /build/src/Functions/IFunction.cpp:498: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d95c72 9. /build/src/Interpreters/ExpressionActions.cpp:636: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x00000000145176f3 10. /build/src/Processors/Transforms/ExpressionTransform.cpp:25: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x0000000016c0b34c 11. /build/src/Processors/ISimpleTransform.h:33: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000011a9a453 12. /build/src/Processors/ISimpleTransform.cpp:89: DB::ISimpleTransform::work() @ 0x000000001699fca0 13. /build/src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x00000000169bd00f 14. /build/src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x00000000169b2105 15. /build/src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeSingleThread(unsigned long) @ 0x00000000169b23be 16. /build/src/Processors/Executors/PipelineExecutor.cpp:454: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x00000000169b0be7 17. /build/src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x00000000169b03f4 18. /build/src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:se190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169bfeab 19. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc3d92 20. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fcca080 21. ? @ 0x00007fbc6213eac3 22. ? @ 0x00007fbc621d0850 Job's origin stack trace: 0. /build/src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000000fc33b84 1. /build/src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000000fcc2ea7 2. /build/src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fcc535c 3. /build/src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000000fcc584d 4. /build/src/Common/ThreadPool.h:279: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x00000000169bf193 5. /build/src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x00000000169bf518 6. /build/src/Server/TCPHandler.cpp:1237: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x00000000168f1525 7. /build/src/Server/TCPHandler.cpp:678: DB::TCPHandler::runImpl() @ 0x00000000168e68e5 8. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 9. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 10. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 11. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 12. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 13. ? @ 0x00007fbc6213eac3 14. ? @ 0x00007fbc621d0850 2025.07.28 11:59:32.385141 [ 17207 ] {14a244a0-5eb7-4e3b-be19-92c9ec3ab804} executeQuery: Code: 36. DB::Exception: The nested column of first argument in function mapFromArrays must not contain NULLs: while executing 'FUNCTION mapFromArrays(__table1.k :: 2, __table1.v :: 0) -> mapFromArrays(__table1.k, __table1.v) Map(LowCardinality(Int32), Int32) : 1'. (BAD_ARGUMENTS) (version 25.3.6.10636.altinitytest (altinity build)) (from [::1]:47386) (comment: 03399_lc_nullable_mapfromarrays.sql) (query 19, line 56) (in query: SELECT mapFromArrays(k, v) FROM 03399_lc_nullable_int_mixed GROUP BY 1;), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x000000000a06b56b 4. /build/src/Functions/map.cpp:249: DB::(anonymous namespace)::FunctionMapFromArrays::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000cf86609 5. /build/src/Functions/IFunctionAdaptors.cpp:10: DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000012d995fa 6. /build/src/Functions/IFunction.cpp:353: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d93b52 7. /build/src/Functions/IFunction.cpp:424: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d94e1b 8. /build/src/Functions/IFunction.cpp:498: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d95c72 9. /build/src/Interpreters/ExpressionActions.cpp:636: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x00000000145176f3 10. /build/src/Processors/Transforms/ExpressionTransform.cpp:25: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x0000000016c0b34c 11. /build/src/Processors/ISimpleTransform.h:33: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000011a9a453 12. /build/src/Processors/ISimpleTransform.cpp:89: DB::ISimpleTransform::work() @ 0x000000001699fca0 13. /build/src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x00000000169bd00f 14. /build/src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x00000000169b2105 15. /build/src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeSingleThread(unsigned long) @ 0x00000000169b23be 16. /build/src/Processors/Executors/PipelineExecutor.cpp:416: void std::__function::__policy_invoker::__call_impl[abi:se190107]>(std::__function::__policy_storage const*) @ 0x00000000169b2e3f 17. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc6653 18. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000000fccc4c3 19. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc3d92 20. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fcca080 21. ? @ 0x00007fbc6213eac3 22. ? @ 0x00007fbc621d0850 2025.07.28 11:59:32.406636 [ 17207 ] {} TCPHandler: Code: 36. DB::Exception: The nested column of first argument in function mapFromArrays must not contain NULLs: while executing 'FUNCTION mapFromArrays(__table1.k :: 2, __table1.v :: 0) -> mapFromArrays(__table1.k, __table1.v) Map(LowCardinality(Int32), Int32) : 1'. (BAD_ARGUMENTS), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x000000000a06b56b 4. /build/src/Functions/map.cpp:249: DB::(anonymous namespace)::FunctionMapFromArrays::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000cf86609 5. /build/src/Functions/IFunctionAdaptors.cpp:10: DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000012d995fa 6. /build/src/Functions/IFunction.cpp:353: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d93b52 7. /build/src/Functions/IFunction.cpp:424: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d94e1b 8. /build/src/Functions/IFunction.cpp:498: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d95c72 9. /build/src/Interpreters/ExpressionActions.cpp:636: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x00000000145176f3 10. /build/src/Processors/Transforms/ExpressionTransform.cpp:25: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x0000000016c0b34c 11. /build/src/Processors/ISimpleTransform.h:33: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000011a9a453 12. /build/src/Processors/ISimpleTransform.cpp:89: DB::ISimpleTransform::work() @ 0x000000001699fca0 13. /build/src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x00000000169bd00f 14. /build/src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x00000000169b2105 15. /build/src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeSingleThread(unsigned long) @ 0x00000000169b23be 16. /build/src/Processors/Executors/PipelineExecutor.cpp:416: void std::__function::__policy_invoker::__call_impl[abi:se190107]>(std::__function::__policy_storage const*) @ 0x00000000169b2e3f 17. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc6653 18. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000000fccc4c3 19. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc3d92 20. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fcca080 21. ? @ 0x00007fbc6213eac3 22. ? @ 0x00007fbc621d0850 Job's origin stack trace: 0. /build/src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000000fc33b84 1. /build/src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000000fcc2ea7 2. /build/src/Common/ThreadPool.cpp:401: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fcc7f1c 3. /build/src/Common/ThreadPool.cpp:494: ThreadPoolImpl>::scheduleOrThrowOnError(std::function, Priority) @ 0x000000000fcc7a0e 4. /build/src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::spawnThreadsImpl() @ 0x00000000169b2c0c 5. /build/src/Processors/Executors/PipelineExecutor.cpp:394: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x00000000169b0ba7 6. /build/src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x00000000169b03f4 7. /build/src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:se190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169bfeab 8. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc3d92 9. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fcca080 10. ? @ 0x00007fbc6213eac3 11. ? @ 0x00007fbc621d0850 Job's origin stack trace: 0. /build/src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000000fc33b84 1. /build/src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000000fcc2ea7 2. /build/src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fcc535c 3. /build/src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000000fcc584d 4. /build/src/Common/ThreadPool.h:279: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x00000000169bf193 5. /build/src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x00000000169bf518 6. /build/src/Server/TCPHandler.cpp:1237: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x00000000168f1525 7. /build/src/Server/TCPHandler.cpp:678: DB::TCPHandler::runImpl() @ 0x00000000168e68e5 8. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 9. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 10. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 11. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 12. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 13. ? @ 0x00007fbc6213eac3 14. ? @ 0x00007fbc621d0850 2025.07.28 11:59:32.583942 [ 3964 ] {} test_13.rmt2 (7f9b740d-015c-470e-8cc6-8ba33be0dc63): auto DB::StorageReplicatedMergeTree::processQueueEntry(ReplicatedMergeTreeQueue::SelectedEntryPtr)::(anonymous class)::operator()(LogEntryPtr &) const: Code: 86. DB::HTTPException: Received error from remote server http://146b4357c08d:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Ftest%2F01165%2Ftest_13%2Frmt%2Freplicas%2F1&part=20250728_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.6.10636.altinitytest (altinity build)) '. (RECEIVED_ERROR_FROM_REMOTE_IO_SERVER), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.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 const&, int&&, String const&, unsigned long&&, String const&) @ 0x000000000feda8d9 4. /build/src/IO/HTTPCommon.cpp:104: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x000000000feda6e2 5. /build/src/IO/HTTPCommon.cpp:93: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x000000000feda537 6. /build/src/IO/ReadWriteBufferFromHTTP.cpp:277: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x000000001184a4c4 7. /build/src/IO/ReadWriteBufferFromHTTP.cpp:285: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x000000001184a615 8. /build/src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x000000001184ae59 9. /build/src/IO/ReadWriteBufferFromHTTP.cpp:472: void std::__function::__policy_invoker::__call_impl[abi:se190107]>(std::__function::__policy_storage const*) @ 0x000000001184cedd 10. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001184858b 11. /build/src/IO/ReadWriteBufferFromHTTP.cpp:465: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x000000001184bf0b 12. /build/src/IO/ReadBuffer.h:60: DB::ReadBuffer::next() @ 0x000000000a148c7b 13. /build/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) @ 0x0000000011849fb2 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]>&)>&, 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&) @ 0x0000000011841980 15. /build/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) @ 0x000000001621208e 16. /build/src/Storages/StorageReplicatedMergeTree.cpp:5228: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl[abi:se190107] const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000015f9a5fe 17. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000015ed8bfd 18. /build/src/Storages/StorageReplicatedMergeTree.cpp:2514: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x0000000015ec9aab 19. /build/src/Storages/StorageReplicatedMergeTree.cpp:2349: DB::StorageReplicatedMergeTree::executeLogEntry(DB::ReplicatedMergeTreeLogEntry&) @ 0x0000000015eba91b 20. /build/src/Storages/StorageReplicatedMergeTree.cpp:3876: bool std::__function::__policy_invoker&)>::__call_impl[abi:se190107])::$_1, bool (std::shared_ptr&)>>(std::__function::__policy_storage const*, std::shared_ptr&) @ 0x0000000015f9837e 21. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000165d6fc3 22. /build/src/Storages/StorageReplicatedMergeTree.cpp:3872: DB::StorageReplicatedMergeTree::processQueueEntry(std::shared_ptr) @ 0x0000000015efc18a 23. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001624c1b2 24. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000162f9c70 25. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x00000000162fa55a 26. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc6653 27. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000000fccc4c3 28. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc3d92 29. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fcca080 30. ? @ 0x00007fbc6213eac3 31. ? @ 0x00007fbc621d0850 (version 25.3.6.10636.altinitytest (altinity build)) 2025.07.28 11:59:32.816844 [ 3961 ] {} test_13.rmt2 (7f9b740d-015c-470e-8cc6-8ba33be0dc63): auto DB::StorageReplicatedMergeTree::processQueueEntry(ReplicatedMergeTreeQueue::SelectedEntryPtr)::(anonymous class)::operator()(LogEntryPtr &) const: Code: 86. DB::HTTPException: Received error from remote server http://146b4357c08d:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Ftest%2F01165%2Ftest_13%2Frmt%2Freplicas%2F1&part=20250728_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.6.10636.altinitytest (altinity build)) '. (RECEIVED_ERROR_FROM_REMOTE_IO_SERVER), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.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 const&, int&&, String const&, unsigned long&&, String const&) @ 0x000000000feda8d9 4. /build/src/IO/HTTPCommon.cpp:104: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x000000000feda6e2 5. /build/src/IO/HTTPCommon.cpp:93: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x000000000feda537 6. /build/src/IO/ReadWriteBufferFromHTTP.cpp:277: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x000000001184a4c4 7. /build/src/IO/ReadWriteBufferFromHTTP.cpp:285: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x000000001184a615 8. /build/src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x000000001184ae59 9. /build/src/IO/ReadWriteBufferFromHTTP.cpp:472: void std::__function::__policy_invoker::__call_impl[abi:se190107]>(std::__function::__policy_storage const*) @ 0x000000001184cedd 10. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001184858b 11. /build/src/IO/ReadWriteBufferFromHTTP.cpp:465: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x000000001184bf0b 12. /build/src/IO/ReadBuffer.h:60: DB::ReadBuffer::next() @ 0x000000000a148c7b 13. /build/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) @ 0x0000000011849fb2 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]>&)>&, 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&) @ 0x0000000011841980 15. /build/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) @ 0x000000001621208e 16. /build/src/Storages/StorageReplicatedMergeTree.cpp:5228: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl[abi:se190107] const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000015f9a5fe 17. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000015ed8bfd 18. /build/src/Storages/StorageReplicatedMergeTree.cpp:2514: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x0000000015ec9aab 19. /build/src/Storages/StorageReplicatedMergeTree.cpp:2349: DB::StorageReplicatedMergeTree::executeLogEntry(DB::ReplicatedMergeTreeLogEntry&) @ 0x0000000015eba91b 20. /build/src/Storages/StorageReplicatedMergeTree.cpp:3876: bool std::__function::__policy_invoker&)>::__call_impl[abi:se190107])::$_1, bool (std::shared_ptr&)>>(std::__function::__policy_storage const*, std::shared_ptr&) @ 0x0000000015f9837e 21. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000165d6fc3 22. /build/src/Storages/StorageReplicatedMergeTree.cpp:3872: DB::StorageReplicatedMergeTree::processQueueEntry(std::shared_ptr) @ 0x0000000015efc18a 23. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001624c1b2 24. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000162f9c70 25. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x00000000162fa55a 26. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc6653 27. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000000fccc4c3 28. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc3d92 29. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fcca080 30. ? @ 0x00007fbc6213eac3 31. ? @ 0x00007fbc621d0850 (version 25.3.6.10636.altinitytest (altinity build)) 2025.07.28 11:59:33.618046 [ 17207 ] {7e12420b-4812-452e-96dd-e417685882ca} executeQuery: Code: 36. DB::Exception: The nested column of first argument in function mapFromArrays must not contain NULLs: while executing 'FUNCTION mapFromArrays(__table1.k :: 2, __table1.v :: 0) -> mapFromArrays(__table1.k, __table1.v) Map(LowCardinality(String), Int32) : 1'. (BAD_ARGUMENTS) (version 25.3.6.10636.altinitytest (altinity build)) (from [::1]:47386) (comment: 03399_lc_nullable_mapfromarrays.sql) (query 28, line 84) (in query: SELECT mapFromArrays(k, v) FROM 03399_lc_nullable_string_mixed;), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x000000000a06b56b 4. /build/src/Functions/map.cpp:249: DB::(anonymous namespace)::FunctionMapFromArrays::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000cf86609 5. /build/src/Functions/IFunctionAdaptors.cpp:10: DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000012d995fa 6. /build/src/Functions/IFunction.cpp:353: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d93b52 7. /build/src/Functions/IFunction.cpp:424: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d94e1b 8. /build/src/Functions/IFunction.cpp:498: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d95c72 9. /build/src/Interpreters/ExpressionActions.cpp:636: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x00000000145176f3 10. /build/src/Processors/Transforms/ExpressionTransform.cpp:25: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x0000000016c0b34c 11. /build/src/Processors/ISimpleTransform.h:33: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000011a9a453 12. /build/src/Processors/ISimpleTransform.cpp:89: DB::ISimpleTransform::work() @ 0x000000001699fca0 13. /build/src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x00000000169bd00f 14. /build/src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x00000000169b2105 15. /build/src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeSingleThread(unsigned long) @ 0x00000000169b23be 16. /build/src/Processors/Executors/PipelineExecutor.cpp:454: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x00000000169b0be7 17. /build/src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x00000000169b03f4 18. /build/src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:se190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169bfeab 19. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc3d92 20. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fcca080 21. ? @ 0x00007fbc6213eac3 22. ? @ 0x00007fbc621d0850 2025.07.28 11:59:33.634314 [ 17207 ] {} TCPHandler: Code: 36. DB::Exception: The nested column of first argument in function mapFromArrays must not contain NULLs: while executing 'FUNCTION mapFromArrays(__table1.k :: 2, __table1.v :: 0) -> mapFromArrays(__table1.k, __table1.v) Map(LowCardinality(String), Int32) : 1'. (BAD_ARGUMENTS), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x000000000a06b56b 4. /build/src/Functions/map.cpp:249: DB::(anonymous namespace)::FunctionMapFromArrays::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000cf86609 5. /build/src/Functions/IFunctionAdaptors.cpp:10: DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000012d995fa 6. /build/src/Functions/IFunction.cpp:353: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d93b52 7. /build/src/Functions/IFunction.cpp:424: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d94e1b 8. /build/src/Functions/IFunction.cpp:498: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d95c72 9. /build/src/Interpreters/ExpressionActions.cpp:636: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x00000000145176f3 10. /build/src/Processors/Transforms/ExpressionTransform.cpp:25: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x0000000016c0b34c 11. /build/src/Processors/ISimpleTransform.h:33: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000011a9a453 12. /build/src/Processors/ISimpleTransform.cpp:89: DB::ISimpleTransform::work() @ 0x000000001699fca0 13. /build/src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x00000000169bd00f 14. /build/src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x00000000169b2105 15. /build/src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeSingleThread(unsigned long) @ 0x00000000169b23be 16. /build/src/Processors/Executors/PipelineExecutor.cpp:454: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x00000000169b0be7 17. /build/src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x00000000169b03f4 18. /build/src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:se190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169bfeab 19. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc3d92 20. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fcca080 21. ? @ 0x00007fbc6213eac3 22. ? @ 0x00007fbc621d0850 Job's origin stack trace: 0. /build/src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000000fc33b84 1. /build/src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000000fcc2ea7 2. /build/src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fcc535c 3. /build/src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000000fcc584d 4. /build/src/Common/ThreadPool.h:279: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x00000000169bf193 5. /build/src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x00000000169bf518 6. /build/src/Server/TCPHandler.cpp:1237: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x00000000168f1525 7. /build/src/Server/TCPHandler.cpp:678: DB::TCPHandler::runImpl() @ 0x00000000168e68e5 8. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 9. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 10. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 11. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 12. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 13. ? @ 0x00007fbc6213eac3 14. ? @ 0x00007fbc621d0850 2025.07.28 11:59:33.677477 [ 17207 ] {e5810ac9-8e78-4678-8eea-afdd83ffedd6} executeQuery: Code: 36. DB::Exception: The nested column of first argument in function mapFromArrays must not contain NULLs: while executing 'FUNCTION mapFromArrays(__table1.k :: 2, __table1.v :: 0) -> mapFromArrays(__table1.k, __table1.v) Map(LowCardinality(String), Int32) : 1'. (BAD_ARGUMENTS) (version 25.3.6.10636.altinitytest (altinity build)) (from [::1]:47386) (comment: 03399_lc_nullable_mapfromarrays.sql) (query 29, line 85) (in query: SELECT mapFromArrays(k, v) FROM 03399_lc_nullable_string_mixed GROUP BY 1;), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x000000000a06b56b 4. /build/src/Functions/map.cpp:249: DB::(anonymous namespace)::FunctionMapFromArrays::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000cf86609 5. /build/src/Functions/IFunctionAdaptors.cpp:10: DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000012d995fa 6. /build/src/Functions/IFunction.cpp:353: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d93b52 7. /build/src/Functions/IFunction.cpp:424: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d94e1b 8. /build/src/Functions/IFunction.cpp:498: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d95c72 9. /build/src/Interpreters/ExpressionActions.cpp:636: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x00000000145176f3 10. /build/src/Processors/Transforms/ExpressionTransform.cpp:25: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x0000000016c0b34c 11. /build/src/Processors/ISimpleTransform.h:33: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000011a9a453 12. /build/src/Processors/ISimpleTransform.cpp:89: DB::ISimpleTransform::work() @ 0x000000001699fca0 13. /build/src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x00000000169bd00f 14. /build/src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x00000000169b2105 15. /build/src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeSingleThread(unsigned long) @ 0x00000000169b23be 16. /build/src/Processors/Executors/PipelineExecutor.cpp:416: void std::__function::__policy_invoker::__call_impl[abi:se190107]>(std::__function::__policy_storage const*) @ 0x00000000169b2e3f 17. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc6653 18. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000000fccc4c3 19. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc3d92 20. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fcca080 21. ? @ 0x00007fbc6213eac3 22. ? @ 0x00007fbc621d0850 2025.07.28 11:59:33.695006 [ 17207 ] {} TCPHandler: Code: 36. DB::Exception: The nested column of first argument in function mapFromArrays must not contain NULLs: while executing 'FUNCTION mapFromArrays(__table1.k :: 2, __table1.v :: 0) -> mapFromArrays(__table1.k, __table1.v) Map(LowCardinality(String), Int32) : 1'. (BAD_ARGUMENTS), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x000000000a06b56b 4. /build/src/Functions/map.cpp:249: DB::(anonymous namespace)::FunctionMapFromArrays::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000cf86609 5. /build/src/Functions/IFunctionAdaptors.cpp:10: DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000012d995fa 6. /build/src/Functions/IFunction.cpp:353: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d93b52 7. /build/src/Functions/IFunction.cpp:424: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d94e1b 8. /build/src/Functions/IFunction.cpp:498: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d95c72 9. /build/src/Interpreters/ExpressionActions.cpp:636: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x00000000145176f3 10. /build/src/Processors/Transforms/ExpressionTransform.cpp:25: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x0000000016c0b34c 11. /build/src/Processors/ISimpleTransform.h:33: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000011a9a453 12. /build/src/Processors/ISimpleTransform.cpp:89: DB::ISimpleTransform::work() @ 0x000000001699fca0 13. /build/src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x00000000169bd00f 14. /build/src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x00000000169b2105 15. /build/src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeSingleThread(unsigned long) @ 0x00000000169b23be 16. /build/src/Processors/Executors/PipelineExecutor.cpp:416: void std::__function::__policy_invoker::__call_impl[abi:se190107]>(std::__function::__policy_storage const*) @ 0x00000000169b2e3f 17. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc6653 18. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000000fccc4c3 19. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc3d92 20. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fcca080 21. ? @ 0x00007fbc6213eac3 22. ? @ 0x00007fbc621d0850 Job's origin stack trace: 0. /build/src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000000fc33b84 1. /build/src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000000fcc2ea7 2. /build/src/Common/ThreadPool.cpp:401: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fcc7f1c 3. /build/src/Common/ThreadPool.cpp:494: ThreadPoolImpl>::scheduleOrThrowOnError(std::function, Priority) @ 0x000000000fcc7a0e 4. /build/src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::spawnThreadsImpl() @ 0x00000000169b2c0c 5. /build/src/Processors/Executors/PipelineExecutor.cpp:394: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x00000000169b0ba7 6. /build/src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x00000000169b03f4 7. /build/src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:se190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169bfeab 8. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc3d92 9. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fcca080 10. ? @ 0x00007fbc6213eac3 11. ? @ 0x00007fbc621d0850 Job's origin stack trace: 0. /build/src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000000fc33b84 1. /build/src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000000fcc2ea7 2. /build/src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fcc535c 3. /build/src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000000fcc584d 4. /build/src/Common/ThreadPool.h:279: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x00000000169bf193 5. /build/src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x00000000169bf518 6. /build/src/Server/TCPHandler.cpp:1237: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x00000000168f1525 7. /build/src/Server/TCPHandler.cpp:678: DB::TCPHandler::runImpl() @ 0x00000000168e68e5 8. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 9. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 10. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 11. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 12. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 13. ? @ 0x00007fbc6213eac3 14. ? @ 0x00007fbc621d0850 2025.07.28 11:59:33.900946 [ 3972 ] {} test_13.rmt2 (7f9b740d-015c-470e-8cc6-8ba33be0dc63): auto DB::StorageReplicatedMergeTree::processQueueEntry(ReplicatedMergeTreeQueue::SelectedEntryPtr)::(anonymous class)::operator()(LogEntryPtr &) const: Code: 86. DB::HTTPException: Received error from remote server http://146b4357c08d:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Ftest%2F01165%2Ftest_13%2Frmt%2Freplicas%2F1&part=20250728_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.6.10636.altinitytest (altinity build)) '. (RECEIVED_ERROR_FROM_REMOTE_IO_SERVER), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.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 const&, int&&, String const&, unsigned long&&, String const&) @ 0x000000000feda8d9 4. /build/src/IO/HTTPCommon.cpp:104: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x000000000feda6e2 5. /build/src/IO/HTTPCommon.cpp:93: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x000000000feda537 6. /build/src/IO/ReadWriteBufferFromHTTP.cpp:277: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x000000001184a4c4 7. /build/src/IO/ReadWriteBufferFromHTTP.cpp:285: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x000000001184a615 8. /build/src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x000000001184ae59 9. /build/src/IO/ReadWriteBufferFromHTTP.cpp:472: void std::__function::__policy_invoker::__call_impl[abi:se190107]>(std::__function::__policy_storage const*) @ 0x000000001184cedd 10. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001184858b 11. /build/src/IO/ReadWriteBufferFromHTTP.cpp:465: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x000000001184bf0b 12. /build/src/IO/ReadBuffer.h:60: DB::ReadBuffer::next() @ 0x000000000a148c7b 13. /build/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) @ 0x0000000011849fb2 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]>&)>&, 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&) @ 0x0000000011841980 15. /build/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) @ 0x000000001621208e 16. /build/src/Storages/StorageReplicatedMergeTree.cpp:5228: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl[abi:se190107] const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000015f9a5fe 17. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000015ed8bfd 18. /build/src/Storages/StorageReplicatedMergeTree.cpp:2514: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x0000000015ec9aab 19. /build/src/Storages/StorageReplicatedMergeTree.cpp:2349: DB::StorageReplicatedMergeTree::executeLogEntry(DB::ReplicatedMergeTreeLogEntry&) @ 0x0000000015eba91b 20. /build/src/Storages/StorageReplicatedMergeTree.cpp:3876: bool std::__function::__policy_invoker&)>::__call_impl[abi:se190107])::$_1, bool (std::shared_ptr&)>>(std::__function::__policy_storage const*, std::shared_ptr&) @ 0x0000000015f9837e 21. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000165d6fc3 22. /build/src/Storages/StorageReplicatedMergeTree.cpp:3872: DB::StorageReplicatedMergeTree::processQueueEntry(std::shared_ptr) @ 0x0000000015efc18a 23. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001624c1b2 24. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000162f9c70 25. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x00000000162fa55a 26. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc6653 27. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000000fccc4c3 28. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc3d92 29. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fcca080 30. ? @ 0x00007fbc6213eac3 31. ? @ 0x00007fbc621d0850 (version 25.3.6.10636.altinitytest (altinity build)) 2025.07.28 11:59:34.167518 [ 17252 ] {6fec0b1e-425b-49a4-bf18-3f4010d2e7fb} executeQuery: Code: 210. DB::NetException: I/O error: Broken pipe, while writing to socket ([::1]:9000 -> [::1]:33040). (NETWORK_ERROR) (version 25.3.6.10636.altinitytest (altinity build)) (from [::1]:33040) (comment: 02030_rocksdb_race_long.sh) (query 1, line 2) (in query: SELECT * FROM system.rocksdb FORMAT Null;), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::NetException::NetException(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&) @ 0x000000000fd50fb5 3. /build/src/IO/WriteBufferFromPocoSocket.cpp:171: DB::WriteBufferFromPocoSocket::nextImpl() @ 0x000000000fd525a7 4. /build/src/IO/WriteBuffer.h:53: DB::WriteBuffer::next() @ 0x000000000a0755be 5. /build/src/Server/TCPHandler.cpp:1422: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x00000000168f181c 6. /build/src/Server/TCPHandler.cpp:678: DB::TCPHandler::runImpl() @ 0x00000000168e68e5 7. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 8. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 9. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 10. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 11. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 12. ? @ 0x00007fbc6213eac3 13. ? @ 0x00007fbc621d0850 2025.07.28 11:59:34.176205 [ 17252 ] {} TCPHandler: Code: 210. DB::NetException: I/O error: Broken pipe, while writing to socket ([::1]:9000 -> [::1]:33040). (NETWORK_ERROR), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::NetException::NetException(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&) @ 0x000000000fd50fb5 3. /build/src/IO/WriteBufferFromPocoSocket.cpp:171: DB::WriteBufferFromPocoSocket::nextImpl() @ 0x000000000fd525a7 4. /build/src/IO/WriteBuffer.h:53: DB::WriteBuffer::next() @ 0x000000000a0755be 5. /build/src/Server/TCPHandler.cpp:1422: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x00000000168f181c 6. /build/src/Server/TCPHandler.cpp:678: DB::TCPHandler::runImpl() @ 0x00000000168e68e5 7. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 8. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 9. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 10. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 11. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 12. ? @ 0x00007fbc6213eac3 13. ? @ 0x00007fbc621d0850 2025.07.28 11:59:34.321255 [ 17306 ] {f8b8b87b-b5d7-4f53-b1b9-be88166ccea5} executeQuery: Code: 219. DB::Exception: New table appeared in database being dropped or detached. Try again. (DATABASE_NOT_EMPTY) (version 25.3.6.10636.altinitytest (altinity build)) (from [::1]:54790) (comment: 02030_rocksdb_race_long.sh) (in query: DROP DATABASE IF EXISTS test_zswt5cf9 SYNC ), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000000a074fcb 4. /build/src/Interpreters/DatabaseCatalog.cpp:608: DB::DatabaseCatalog::detachDatabase(std::shared_ptr, String const&, bool, bool) @ 0x00000000144f41b9 5. /build/src/Interpreters/InterpreterDropQuery.cpp:482: DB::InterpreterDropQuery::executeToDatabaseImpl(DB::ASTDropQuery const&, std::shared_ptr&, std::vector, DB::UUIDTag>, std::allocator, DB::UUIDTag>>>&) @ 0x00000000149179be 6. /build/src/Interpreters/InterpreterDropQuery.cpp:363: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x0000000014913988 7. /build/src/Interpreters/InterpreterDropQuery.cpp:99: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000014913142 8. /build/src/Interpreters/InterpreterDropQuery.cpp:72: DB::InterpreterDropQuery::execute() @ 0x0000000014912b65 9. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88dc9 10. /build/src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x0000000014c8ca7b 11. /build/src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000001686da12 12. /build/src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x0000000016870807 13. /build/src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x0000000016907e99 14. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 15. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 16. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 17. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 18. ? @ 0x00007fbc6213eac3 19. ? @ 0x00007fbc621d0850 2025.07.28 11:59:34.323007 [ 17306 ] {f8b8b87b-b5d7-4f53-b1b9-be88166ccea5} 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. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000000a074fcb 4. /build/src/Interpreters/DatabaseCatalog.cpp:608: DB::DatabaseCatalog::detachDatabase(std::shared_ptr, String const&, bool, bool) @ 0x00000000144f41b9 5. /build/src/Interpreters/InterpreterDropQuery.cpp:482: DB::InterpreterDropQuery::executeToDatabaseImpl(DB::ASTDropQuery const&, std::shared_ptr&, std::vector, DB::UUIDTag>, std::allocator, DB::UUIDTag>>>&) @ 0x00000000149179be 6. /build/src/Interpreters/InterpreterDropQuery.cpp:363: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x0000000014913988 7. /build/src/Interpreters/InterpreterDropQuery.cpp:99: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000014913142 8. /build/src/Interpreters/InterpreterDropQuery.cpp:72: DB::InterpreterDropQuery::execute() @ 0x0000000014912b65 9. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88dc9 10. /build/src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x0000000014c8ca7b 11. /build/src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000001686da12 12. /build/src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x0000000016870807 13. /build/src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x0000000016907e99 14. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 15. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 16. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 17. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 18. ? @ 0x00007fbc6213eac3 19. ? @ 0x00007fbc621d0850 (version 25.3.6.10636.altinitytest (altinity build)) 2025.07.28 11:59:34.385085 [ 3970 ] {} test_13.rmt2 (7f9b740d-015c-470e-8cc6-8ba33be0dc63): auto DB::StorageReplicatedMergeTree::processQueueEntry(ReplicatedMergeTreeQueue::SelectedEntryPtr)::(anonymous class)::operator()(LogEntryPtr &) const: Code: 86. DB::HTTPException: Received error from remote server http://146b4357c08d:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Ftest%2F01165%2Ftest_13%2Frmt%2Freplicas%2F1&part=20250728_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.6.10636.altinitytest (altinity build)) '. (RECEIVED_ERROR_FROM_REMOTE_IO_SERVER), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.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 const&, int&&, String const&, unsigned long&&, String const&) @ 0x000000000feda8d9 4. /build/src/IO/HTTPCommon.cpp:104: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x000000000feda6e2 5. /build/src/IO/HTTPCommon.cpp:93: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x000000000feda537 6. /build/src/IO/ReadWriteBufferFromHTTP.cpp:277: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x000000001184a4c4 7. /build/src/IO/ReadWriteBufferFromHTTP.cpp:285: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x000000001184a615 8. /build/src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x000000001184ae59 9. /build/src/IO/ReadWriteBufferFromHTTP.cpp:472: void std::__function::__policy_invoker::__call_impl[abi:se190107]>(std::__function::__policy_storage const*) @ 0x000000001184cedd 10. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001184858b 11. /build/src/IO/ReadWriteBufferFromHTTP.cpp:465: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x000000001184bf0b 12. /build/src/IO/ReadBuffer.h:60: DB::ReadBuffer::next() @ 0x000000000a148c7b 13. /build/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) @ 0x0000000011849fb2 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]>&)>&, 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&) @ 0x0000000011841980 15. /build/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) @ 0x000000001621208e 16. /build/src/Storages/StorageReplicatedMergeTree.cpp:5228: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl[abi:se190107] const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000015f9a5fe 17. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000015ed8bfd 18. /build/src/Storages/StorageReplicatedMergeTree.cpp:2514: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x0000000015ec9aab 19. /build/src/Storages/StorageReplicatedMergeTree.cpp:2349: DB::StorageReplicatedMergeTree::executeLogEntry(DB::ReplicatedMergeTreeLogEntry&) @ 0x0000000015eba91b 20. /build/src/Storages/StorageReplicatedMergeTree.cpp:3876: bool std::__function::__policy_invoker&)>::__call_impl[abi:se190107])::$_1, bool (std::shared_ptr&)>>(std::__function::__policy_storage const*, std::shared_ptr&) @ 0x0000000015f9837e 21. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000165d6fc3 22. /build/src/Storages/StorageReplicatedMergeTree.cpp:3872: DB::StorageReplicatedMergeTree::processQueueEntry(std::shared_ptr) @ 0x0000000015efc18a 23. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001624c1b2 24. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000162f9c70 25. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x00000000162fa55a 26. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc6653 27. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000000fccc4c3 28. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc3d92 29. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fcca080 30. ? @ 0x00007fbc6213eac3 31. ? @ 0x00007fbc621d0850 (version 25.3.6.10636.altinitytest (altinity build)) 2025.07.28 11:59:35.117024 [ 3968 ] {} test_13.rmt2 (7f9b740d-015c-470e-8cc6-8ba33be0dc63): auto DB::StorageReplicatedMergeTree::processQueueEntry(ReplicatedMergeTreeQueue::SelectedEntryPtr)::(anonymous class)::operator()(LogEntryPtr &) const: Code: 86. DB::HTTPException: Received error from remote server http://146b4357c08d:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Ftest%2F01165%2Ftest_13%2Frmt%2Freplicas%2F1&part=20250728_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.6.10636.altinitytest (altinity build)) '. (RECEIVED_ERROR_FROM_REMOTE_IO_SERVER), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.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 const&, int&&, String const&, unsigned long&&, String const&) @ 0x000000000feda8d9 4. /build/src/IO/HTTPCommon.cpp:104: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x000000000feda6e2 5. /build/src/IO/HTTPCommon.cpp:93: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x000000000feda537 6. /build/src/IO/ReadWriteBufferFromHTTP.cpp:277: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x000000001184a4c4 7. /build/src/IO/ReadWriteBufferFromHTTP.cpp:285: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x000000001184a615 8. /build/src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x000000001184ae59 9. /build/src/IO/ReadWriteBufferFromHTTP.cpp:472: void std::__function::__policy_invoker::__call_impl[abi:se190107]>(std::__function::__policy_storage const*) @ 0x000000001184cedd 10. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001184858b 11. /build/src/IO/ReadWriteBufferFromHTTP.cpp:465: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x000000001184bf0b 12. /build/src/IO/ReadBuffer.h:60: DB::ReadBuffer::next() @ 0x000000000a148c7b 13. /build/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) @ 0x0000000011849fb2 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]>&)>&, 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&) @ 0x0000000011841980 15. /build/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) @ 0x000000001621208e 16. /build/src/Storages/StorageReplicatedMergeTree.cpp:5228: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl[abi:se190107] const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000015f9a5fe 17. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000015ed8bfd 18. /build/src/Storages/StorageReplicatedMergeTree.cpp:2514: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x0000000015ec9aab 19. /build/src/Storages/StorageReplicatedMergeTree.cpp:2349: DB::StorageReplicatedMergeTree::executeLogEntry(DB::ReplicatedMergeTreeLogEntry&) @ 0x0000000015eba91b 20. /build/src/Storages/StorageReplicatedMergeTree.cpp:3876: bool std::__function::__policy_invoker&)>::__call_impl[abi:se190107])::$_1, bool (std::shared_ptr&)>>(std::__function::__policy_storage const*, std::shared_ptr&) @ 0x0000000015f9837e 21. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000165d6fc3 22. /build/src/Storages/StorageReplicatedMergeTree.cpp:3872: DB::StorageReplicatedMergeTree::processQueueEntry(std::shared_ptr) @ 0x0000000015efc18a 23. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001624c1b2 24. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000162f9c70 25. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x00000000162fa55a 26. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc6653 27. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000000fccc4c3 28. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc3d92 29. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fcca080 30. ? @ 0x00007fbc6213eac3 31. ? @ 0x00007fbc621d0850 (version 25.3.6.10636.altinitytest (altinity build)) 2025.07.28 11:59:35.838462 [ 3965 ] {} test_13.rmt2 (7f9b740d-015c-470e-8cc6-8ba33be0dc63): auto DB::StorageReplicatedMergeTree::processQueueEntry(ReplicatedMergeTreeQueue::SelectedEntryPtr)::(anonymous class)::operator()(LogEntryPtr &) const: Code: 86. DB::HTTPException: Received error from remote server http://146b4357c08d:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Ftest%2F01165%2Ftest_13%2Frmt%2Freplicas%2F1&part=20250728_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.6.10636.altinitytest (altinity build)) '. (RECEIVED_ERROR_FROM_REMOTE_IO_SERVER), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.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 const&, int&&, String const&, unsigned long&&, String const&) @ 0x000000000feda8d9 4. /build/src/IO/HTTPCommon.cpp:104: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x000000000feda6e2 5. /build/src/IO/HTTPCommon.cpp:93: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x000000000feda537 6. /build/src/IO/ReadWriteBufferFromHTTP.cpp:277: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x000000001184a4c4 7. /build/src/IO/ReadWriteBufferFromHTTP.cpp:285: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x000000001184a615 8. /build/src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x000000001184ae59 9. /build/src/IO/ReadWriteBufferFromHTTP.cpp:472: void std::__function::__policy_invoker::__call_impl[abi:se190107]>(std::__function::__policy_storage const*) @ 0x000000001184cedd 10. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001184858b 11. /build/src/IO/ReadWriteBufferFromHTTP.cpp:465: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x000000001184bf0b 12. /build/src/IO/ReadBuffer.h:60: DB::ReadBuffer::next() @ 0x000000000a148c7b 13. /build/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) @ 0x0000000011849fb2 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]>&)>&, 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&) @ 0x0000000011841980 15. /build/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) @ 0x000000001621208e 16. /build/src/Storages/StorageReplicatedMergeTree.cpp:5228: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl[abi:se190107] const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000015f9a5fe 17. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000015ed8bfd 18. /build/src/Storages/StorageReplicatedMergeTree.cpp:2514: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x0000000015ec9aab 19. /build/src/Storages/StorageReplicatedMergeTree.cpp:2349: DB::StorageReplicatedMergeTree::executeLogEntry(DB::ReplicatedMergeTreeLogEntry&) @ 0x0000000015eba91b 20. /build/src/Storages/StorageReplicatedMergeTree.cpp:3876: bool std::__function::__policy_invoker&)>::__call_impl[abi:se190107])::$_1, bool (std::shared_ptr&)>>(std::__function::__policy_storage const*, std::shared_ptr&) @ 0x0000000015f9837e 21. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000165d6fc3 22. /build/src/Storages/StorageReplicatedMergeTree.cpp:3872: DB::StorageReplicatedMergeTree::processQueueEntry(std::shared_ptr) @ 0x0000000015efc18a 23. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001624c1b2 24. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000162f9c70 25. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x00000000162fa55a 26. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc6653 27. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000000fccc4c3 28. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc3d92 29. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fcca080 30. ? @ 0x00007fbc6213eac3 31. ? @ 0x00007fbc621d0850 (version 25.3.6.10636.altinitytest (altinity build)) 2025.07.28 11:59:36.637970 [ 3960 ] {} test_13.rmt2 (7f9b740d-015c-470e-8cc6-8ba33be0dc63): auto DB::StorageReplicatedMergeTree::processQueueEntry(ReplicatedMergeTreeQueue::SelectedEntryPtr)::(anonymous class)::operator()(LogEntryPtr &) const: Code: 86. DB::HTTPException: Received error from remote server http://146b4357c08d:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Ftest%2F01165%2Ftest_13%2Frmt%2Freplicas%2F1&part=20250728_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.6.10636.altinitytest (altinity build)) '. (RECEIVED_ERROR_FROM_REMOTE_IO_SERVER), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.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 const&, int&&, String const&, unsigned long&&, String const&) @ 0x000000000feda8d9 4. /build/src/IO/HTTPCommon.cpp:104: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x000000000feda6e2 5. /build/src/IO/HTTPCommon.cpp:93: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x000000000feda537 6. /build/src/IO/ReadWriteBufferFromHTTP.cpp:277: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x000000001184a4c4 7. /build/src/IO/ReadWriteBufferFromHTTP.cpp:285: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x000000001184a615 8. /build/src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x000000001184ae59 9. /build/src/IO/ReadWriteBufferFromHTTP.cpp:472: void std::__function::__policy_invoker::__call_impl[abi:se190107]>(std::__function::__policy_storage const*) @ 0x000000001184cedd 10. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001184858b 11. /build/src/IO/ReadWriteBufferFromHTTP.cpp:465: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x000000001184bf0b 12. /build/src/IO/ReadBuffer.h:60: DB::ReadBuffer::next() @ 0x000000000a148c7b 13. /build/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) @ 0x0000000011849fb2 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]>&)>&, 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&) @ 0x0000000011841980 15. /build/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) @ 0x000000001621208e 16. /build/src/Storages/StorageReplicatedMergeTree.cpp:5228: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl[abi:se190107] const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000015f9a5fe 17. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000015ed8bfd 18. /build/src/Storages/StorageReplicatedMergeTree.cpp:2514: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x0000000015ec9aab 19. /build/src/Storages/StorageReplicatedMergeTree.cpp:2349: DB::StorageReplicatedMergeTree::executeLogEntry(DB::ReplicatedMergeTreeLogEntry&) @ 0x0000000015eba91b 20. /build/src/Storages/StorageReplicatedMergeTree.cpp:3876: bool std::__function::__policy_invoker&)>::__call_impl[abi:se190107])::$_1, bool (std::shared_ptr&)>>(std::__function::__policy_storage const*, std::shared_ptr&) @ 0x0000000015f9837e 21. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000165d6fc3 22. /build/src/Storages/StorageReplicatedMergeTree.cpp:3872: DB::StorageReplicatedMergeTree::processQueueEntry(std::shared_ptr) @ 0x0000000015efc18a 23. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001624c1b2 24. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000162f9c70 25. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x00000000162fa55a 26. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc6653 27. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000000fccc4c3 28. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc3d92 29. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fcca080 30. ? @ 0x00007fbc6213eac3 31. ? @ 0x00007fbc621d0850 (version 25.3.6.10636.altinitytest (altinity build)) 2025.07.28 11:59:37.537640 [ 3969 ] {} test_13.rmt2 (7f9b740d-015c-470e-8cc6-8ba33be0dc63): auto DB::StorageReplicatedMergeTree::processQueueEntry(ReplicatedMergeTreeQueue::SelectedEntryPtr)::(anonymous class)::operator()(LogEntryPtr &) const: Code: 86. DB::HTTPException: Received error from remote server http://146b4357c08d:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Ftest%2F01165%2Ftest_13%2Frmt%2Freplicas%2F1&part=20250728_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.6.10636.altinitytest (altinity build)) '. (RECEIVED_ERROR_FROM_REMOTE_IO_SERVER), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.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 const&, int&&, String const&, unsigned long&&, String const&) @ 0x000000000feda8d9 4. /build/src/IO/HTTPCommon.cpp:104: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x000000000feda6e2 5. /build/src/IO/HTTPCommon.cpp:93: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x000000000feda537 6. /build/src/IO/ReadWriteBufferFromHTTP.cpp:277: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x000000001184a4c4 7. /build/src/IO/ReadWriteBufferFromHTTP.cpp:285: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x000000001184a615 8. /build/src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x000000001184ae59 9. /build/src/IO/ReadWriteBufferFromHTTP.cpp:472: void std::__function::__policy_invoker::__call_impl[abi:se190107]>(std::__function::__policy_storage const*) @ 0x000000001184cedd 10. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001184858b 11. /build/src/IO/ReadWriteBufferFromHTTP.cpp:465: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x000000001184bf0b 12. /build/src/IO/ReadBuffer.h:60: DB::ReadBuffer::next() @ 0x000000000a148c7b 13. /build/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) @ 0x0000000011849fb2 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]>&)>&, 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&) @ 0x0000000011841980 15. /build/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) @ 0x000000001621208e 16. /build/src/Storages/StorageReplicatedMergeTree.cpp:5228: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl[abi:se190107] const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000015f9a5fe 17. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000015ed8bfd 18. /build/src/Storages/StorageReplicatedMergeTree.cpp:2514: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x0000000015ec9aab 19. /build/src/Storages/StorageReplicatedMergeTree.cpp:2349: DB::StorageReplicatedMergeTree::executeLogEntry(DB::ReplicatedMergeTreeLogEntry&) @ 0x0000000015eba91b 20. /build/src/Storages/StorageReplicatedMergeTree.cpp:3876: bool std::__function::__policy_invoker&)>::__call_impl[abi:se190107])::$_1, bool (std::shared_ptr&)>>(std::__function::__policy_storage const*, std::shared_ptr&) @ 0x0000000015f9837e 21. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000165d6fc3 22. /build/src/Storages/StorageReplicatedMergeTree.cpp:3872: DB::StorageReplicatedMergeTree::processQueueEntry(std::shared_ptr) @ 0x0000000015efc18a 23. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001624c1b2 24. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000162f9c70 25. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x00000000162fa55a 26. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc6653 27. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000000fccc4c3 28. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc3d92 29. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fcca080 30. ? @ 0x00007fbc6213eac3 31. ? @ 0x00007fbc621d0850 (version 25.3.6.10636.altinitytest (altinity build)) 2025.07.28 11:59:37.848950 [ 3962 ] {} test_13.rmt2 (7f9b740d-015c-470e-8cc6-8ba33be0dc63): auto DB::StorageReplicatedMergeTree::processQueueEntry(ReplicatedMergeTreeQueue::SelectedEntryPtr)::(anonymous class)::operator()(LogEntryPtr &) const: Code: 86. DB::HTTPException: Received error from remote server http://146b4357c08d:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Ftest%2F01165%2Ftest_13%2Frmt%2Freplicas%2F1&part=20250728_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.6.10636.altinitytest (altinity build)) '. (RECEIVED_ERROR_FROM_REMOTE_IO_SERVER), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.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 const&, int&&, String const&, unsigned long&&, String const&) @ 0x000000000feda8d9 4. /build/src/IO/HTTPCommon.cpp:104: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x000000000feda6e2 5. /build/src/IO/HTTPCommon.cpp:93: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x000000000feda537 6. /build/src/IO/ReadWriteBufferFromHTTP.cpp:277: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x000000001184a4c4 7. /build/src/IO/ReadWriteBufferFromHTTP.cpp:285: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x000000001184a615 8. /build/src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x000000001184ae59 9. /build/src/IO/ReadWriteBufferFromHTTP.cpp:472: void std::__function::__policy_invoker::__call_impl[abi:se190107]>(std::__function::__policy_storage const*) @ 0x000000001184cedd 10. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001184858b 11. /build/src/IO/ReadWriteBufferFromHTTP.cpp:465: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x000000001184bf0b 12. /build/src/IO/ReadBuffer.h:60: DB::ReadBuffer::next() @ 0x000000000a148c7b 13. /build/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) @ 0x0000000011849fb2 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]>&)>&, 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&) @ 0x0000000011841980 15. /build/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) @ 0x000000001621208e 16. /build/src/Storages/StorageReplicatedMergeTree.cpp:5228: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl[abi:se190107] const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000015f9a5fe 17. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000015ed8bfd 18. /build/src/Storages/StorageReplicatedMergeTree.cpp:2514: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x0000000015ec9aab 19. /build/src/Storages/StorageReplicatedMergeTree.cpp:2349: DB::StorageReplicatedMergeTree::executeLogEntry(DB::ReplicatedMergeTreeLogEntry&) @ 0x0000000015eba91b 20. /build/src/Storages/StorageReplicatedMergeTree.cpp:3876: bool std::__function::__policy_invoker&)>::__call_impl[abi:se190107])::$_1, bool (std::shared_ptr&)>>(std::__function::__policy_storage const*, std::shared_ptr&) @ 0x0000000015f9837e 21. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000165d6fc3 22. /build/src/Storages/StorageReplicatedMergeTree.cpp:3872: DB::StorageReplicatedMergeTree::processQueueEntry(std::shared_ptr) @ 0x0000000015efc18a 23. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001624c1b2 24. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000162f9c70 25. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x00000000162fa55a 26. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc6653 27. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000000fccc4c3 28. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc3d92 29. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fcca080 30. ? @ 0x00007fbc6213eac3 31. ? @ 0x00007fbc621d0850 (version 25.3.6.10636.altinitytest (altinity build)) 2025.07.28 11:59:38.114909 [ 3977 ] {} test_13.rmt2 (7f9b740d-015c-470e-8cc6-8ba33be0dc63): auto DB::StorageReplicatedMergeTree::processQueueEntry(ReplicatedMergeTreeQueue::SelectedEntryPtr)::(anonymous class)::operator()(LogEntryPtr &) const: Code: 86. DB::HTTPException: Received error from remote server http://146b4357c08d:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Ftest%2F01165%2Ftest_13%2Frmt%2Freplicas%2F1&part=20250728_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.6.10636.altinitytest (altinity build)) '. (RECEIVED_ERROR_FROM_REMOTE_IO_SERVER), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.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 const&, int&&, String const&, unsigned long&&, String const&) @ 0x000000000feda8d9 4. /build/src/IO/HTTPCommon.cpp:104: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x000000000feda6e2 5. /build/src/IO/HTTPCommon.cpp:93: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x000000000feda537 6. /build/src/IO/ReadWriteBufferFromHTTP.cpp:277: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x000000001184a4c4 7. /build/src/IO/ReadWriteBufferFromHTTP.cpp:285: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x000000001184a615 8. /build/src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x000000001184ae59 9. /build/src/IO/ReadWriteBufferFromHTTP.cpp:472: void std::__function::__policy_invoker::__call_impl[abi:se190107]>(std::__function::__policy_storage const*) @ 0x000000001184cedd 10. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001184858b 11. /build/src/IO/ReadWriteBufferFromHTTP.cpp:465: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x000000001184bf0b 12. /build/src/IO/ReadBuffer.h:60: DB::ReadBuffer::next() @ 0x000000000a148c7b 13. /build/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) @ 0x0000000011849fb2 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]>&)>&, 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&) @ 0x0000000011841980 15. /build/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) @ 0x000000001621208e 16. /build/src/Storages/StorageReplicatedMergeTree.cpp:5228: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl[abi:se190107] const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000015f9a5fe 17. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000015ed8bfd 18. /build/src/Storages/StorageReplicatedMergeTree.cpp:2514: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x0000000015ec9aab 19. /build/src/Storages/StorageReplicatedMergeTree.cpp:2349: DB::StorageReplicatedMergeTree::executeLogEntry(DB::ReplicatedMergeTreeLogEntry&) @ 0x0000000015eba91b 20. /build/src/Storages/StorageReplicatedMergeTree.cpp:3876: bool std::__function::__policy_invoker&)>::__call_impl[abi:se190107])::$_1, bool (std::shared_ptr&)>>(std::__function::__policy_storage const*, std::shared_ptr&) @ 0x0000000015f9837e 21. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000165d6fc3 22. /build/src/Storages/StorageReplicatedMergeTree.cpp:3872: DB::StorageReplicatedMergeTree::processQueueEntry(std::shared_ptr) @ 0x0000000015efc18a 23. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001624c1b2 24. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000162f9c70 25. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x00000000162fa55a 26. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc6653 27. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000000fccc4c3 28. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc3d92 29. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fcca080 30. ? @ 0x00007fbc6213eac3 31. ? @ 0x00007fbc621d0850 (version 25.3.6.10636.altinitytest (altinity build)) 2025.07.28 11:59:38.504011 [ 3967 ] {} test_13.rmt2 (7f9b740d-015c-470e-8cc6-8ba33be0dc63): auto DB::StorageReplicatedMergeTree::processQueueEntry(ReplicatedMergeTreeQueue::SelectedEntryPtr)::(anonymous class)::operator()(LogEntryPtr &) const: Code: 86. DB::HTTPException: Received error from remote server http://146b4357c08d:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Ftest%2F01165%2Ftest_13%2Frmt%2Freplicas%2F1&part=20250728_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.6.10636.altinitytest (altinity build)) '. (RECEIVED_ERROR_FROM_REMOTE_IO_SERVER), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.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 const&, int&&, String const&, unsigned long&&, String const&) @ 0x000000000feda8d9 4. /build/src/IO/HTTPCommon.cpp:104: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x000000000feda6e2 5. /build/src/IO/HTTPCommon.cpp:93: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x000000000feda537 6. /build/src/IO/ReadWriteBufferFromHTTP.cpp:277: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x000000001184a4c4 7. /build/src/IO/ReadWriteBufferFromHTTP.cpp:285: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x000000001184a615 8. /build/src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x000000001184ae59 9. /build/src/IO/ReadWriteBufferFromHTTP.cpp:472: void std::__function::__policy_invoker::__call_impl[abi:se190107]>(std::__function::__policy_storage const*) @ 0x000000001184cedd 10. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001184858b 11. /build/src/IO/ReadWriteBufferFromHTTP.cpp:465: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x000000001184bf0b 12. /build/src/IO/ReadBuffer.h:60: DB::ReadBuffer::next() @ 0x000000000a148c7b 13. /build/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) @ 0x0000000011849fb2 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]>&)>&, 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&) @ 0x0000000011841980 15. /build/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) @ 0x000000001621208e 16. /build/src/Storages/StorageReplicatedMergeTree.cpp:5228: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl[abi:se190107] const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000015f9a5fe 17. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000015ed8bfd 18. /build/src/Storages/StorageReplicatedMergeTree.cpp:2514: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x0000000015ec9aab 19. /build/src/Storages/StorageReplicatedMergeTree.cpp:2349: DB::StorageReplicatedMergeTree::executeLogEntry(DB::ReplicatedMergeTreeLogEntry&) @ 0x0000000015eba91b 20. /build/src/Storages/StorageReplicatedMergeTree.cpp:3876: bool std::__function::__policy_invoker&)>::__call_impl[abi:se190107])::$_1, bool (std::shared_ptr&)>>(std::__function::__policy_storage const*, std::shared_ptr&) @ 0x0000000015f9837e 21. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000165d6fc3 22. /build/src/Storages/StorageReplicatedMergeTree.cpp:3872: DB::StorageReplicatedMergeTree::processQueueEntry(std::shared_ptr) @ 0x0000000015efc18a 23. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001624c1b2 24. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000162f9c70 25. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x00000000162fa55a 26. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc6653 27. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000000fccc4c3 28. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc3d92 29. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fcca080 30. ? @ 0x00007fbc6213eac3 31. ? @ 0x00007fbc621d0850 (version 25.3.6.10636.altinitytest (altinity build)) 2025.07.28 11:59:39.433404 [ 3972 ] {} test_13.rmt2 (7f9b740d-015c-470e-8cc6-8ba33be0dc63): auto DB::StorageReplicatedMergeTree::processQueueEntry(ReplicatedMergeTreeQueue::SelectedEntryPtr)::(anonymous class)::operator()(LogEntryPtr &) const: Code: 86. DB::HTTPException: Received error from remote server http://146b4357c08d:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Ftest%2F01165%2Ftest_13%2Frmt%2Freplicas%2F1&part=20250728_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.6.10636.altinitytest (altinity build)) '. (RECEIVED_ERROR_FROM_REMOTE_IO_SERVER), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.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 const&, int&&, String const&, unsigned long&&, String const&) @ 0x000000000feda8d9 4. /build/src/IO/HTTPCommon.cpp:104: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x000000000feda6e2 5. /build/src/IO/HTTPCommon.cpp:93: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x000000000feda537 6. /build/src/IO/ReadWriteBufferFromHTTP.cpp:277: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x000000001184a4c4 7. /build/src/IO/ReadWriteBufferFromHTTP.cpp:285: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x000000001184a615 8. /build/src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x000000001184ae59 9. /build/src/IO/ReadWriteBufferFromHTTP.cpp:472: void std::__function::__policy_invoker::__call_impl[abi:se190107]>(std::__function::__policy_storage const*) @ 0x000000001184cedd 10. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001184858b 11. /build/src/IO/ReadWriteBufferFromHTTP.cpp:465: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x000000001184bf0b 12. /build/src/IO/ReadBuffer.h:60: DB::ReadBuffer::next() @ 0x000000000a148c7b 13. /build/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) @ 0x0000000011849fb2 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]>&)>&, 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&) @ 0x0000000011841980 15. /build/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) @ 0x000000001621208e 16. /build/src/Storages/StorageReplicatedMergeTree.cpp:5228: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl[abi:se190107] const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000015f9a5fe 17. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000015ed8bfd 18. /build/src/Storages/StorageReplicatedMergeTree.cpp:2514: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x0000000015ec9aab 19. /build/src/Storages/StorageReplicatedMergeTree.cpp:2349: DB::StorageReplicatedMergeTree::executeLogEntry(DB::ReplicatedMergeTreeLogEntry&) @ 0x0000000015eba91b 20. /build/src/Storages/StorageReplicatedMergeTree.cpp:3876: bool std::__function::__policy_invoker&)>::__call_impl[abi:se190107])::$_1, bool (std::shared_ptr&)>>(std::__function::__policy_storage const*, std::shared_ptr&) @ 0x0000000015f9837e 21. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000165d6fc3 22. /build/src/Storages/StorageReplicatedMergeTree.cpp:3872: DB::StorageReplicatedMergeTree::processQueueEntry(std::shared_ptr) @ 0x0000000015efc18a 23. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001624c1b2 24. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000162f9c70 25. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x00000000162fa55a 26. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc6653 27. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000000fccc4c3 28. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc3d92 29. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fcca080 30. ? @ 0x00007fbc6213eac3 31. ? @ 0x00007fbc621d0850 (version 25.3.6.10636.altinitytest (altinity build)) 2025.07.28 11:59:39.579002 [ 3960 ] {} test_13.rmt2 (7f9b740d-015c-470e-8cc6-8ba33be0dc63): auto DB::StorageReplicatedMergeTree::processQueueEntry(ReplicatedMergeTreeQueue::SelectedEntryPtr)::(anonymous class)::operator()(LogEntryPtr &) const: Code: 86. DB::HTTPException: Received error from remote server http://146b4357c08d:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Ftest%2F01165%2Ftest_13%2Frmt%2Freplicas%2F1&part=20250728_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.6.10636.altinitytest (altinity build)) '. (RECEIVED_ERROR_FROM_REMOTE_IO_SERVER), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.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 const&, int&&, String const&, unsigned long&&, String const&) @ 0x000000000feda8d9 4. /build/src/IO/HTTPCommon.cpp:104: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x000000000feda6e2 5. /build/src/IO/HTTPCommon.cpp:93: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x000000000feda537 6. /build/src/IO/ReadWriteBufferFromHTTP.cpp:277: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x000000001184a4c4 7. /build/src/IO/ReadWriteBufferFromHTTP.cpp:285: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x000000001184a615 8. /build/src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x000000001184ae59 9. /build/src/IO/ReadWriteBufferFromHTTP.cpp:472: void std::__function::__policy_invoker::__call_impl[abi:se190107]>(std::__function::__policy_storage const*) @ 0x000000001184cedd 10. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001184858b 11. /build/src/IO/ReadWriteBufferFromHTTP.cpp:465: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x000000001184bf0b 12. /build/src/IO/ReadBuffer.h:60: DB::ReadBuffer::next() @ 0x000000000a148c7b 13. /build/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) @ 0x0000000011849fb2 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]>&)>&, 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&) @ 0x0000000011841980 15. /build/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) @ 0x000000001621208e 16. /build/src/Storages/StorageReplicatedMergeTree.cpp:5228: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl[abi:se190107] const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000015f9a5fe 17. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000015ed8bfd 18. /build/src/Storages/StorageReplicatedMergeTree.cpp:2514: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x0000000015ec9aab 19. /build/src/Storages/StorageReplicatedMergeTree.cpp:2349: DB::StorageReplicatedMergeTree::executeLogEntry(DB::ReplicatedMergeTreeLogEntry&) @ 0x0000000015eba91b 20. /build/src/Storages/StorageReplicatedMergeTree.cpp:3876: bool std::__function::__policy_invoker&)>::__call_impl[abi:se190107])::$_1, bool (std::shared_ptr&)>>(std::__function::__policy_storage const*, std::shared_ptr&) @ 0x0000000015f9837e 21. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000165d6fc3 22. /build/src/Storages/StorageReplicatedMergeTree.cpp:3872: DB::StorageReplicatedMergeTree::processQueueEntry(std::shared_ptr) @ 0x0000000015efc18a 23. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001624c1b2 24. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000162f9c70 25. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x00000000162fa55a 26. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc6653 27. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000000fccc4c3 28. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc3d92 29. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fcca080 30. ? @ 0x00007fbc6213eac3 31. ? @ 0x00007fbc621d0850 (version 25.3.6.10636.altinitytest (altinity build)) 2025.07.28 11:59:39.864357 [ 3965 ] {} test_13.rmt2 (7f9b740d-015c-470e-8cc6-8ba33be0dc63): auto DB::StorageReplicatedMergeTree::processQueueEntry(ReplicatedMergeTreeQueue::SelectedEntryPtr)::(anonymous class)::operator()(LogEntryPtr &) const: Code: 86. DB::HTTPException: Received error from remote server http://146b4357c08d:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Ftest%2F01165%2Ftest_13%2Frmt%2Freplicas%2F1&part=20250728_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.6.10636.altinitytest (altinity build)) '. (RECEIVED_ERROR_FROM_REMOTE_IO_SERVER), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.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 const&, int&&, String const&, unsigned long&&, String const&) @ 0x000000000feda8d9 4. /build/src/IO/HTTPCommon.cpp:104: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x000000000feda6e2 5. /build/src/IO/HTTPCommon.cpp:93: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x000000000feda537 6. /build/src/IO/ReadWriteBufferFromHTTP.cpp:277: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x000000001184a4c4 7. /build/src/IO/ReadWriteBufferFromHTTP.cpp:285: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x000000001184a615 8. /build/src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x000000001184ae59 9. /build/src/IO/ReadWriteBufferFromHTTP.cpp:472: void std::__function::__policy_invoker::__call_impl[abi:se190107]>(std::__function::__policy_storage const*) @ 0x000000001184cedd 10. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001184858b 11. /build/src/IO/ReadWriteBufferFromHTTP.cpp:465: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x000000001184bf0b 12. /build/src/IO/ReadBuffer.h:60: DB::ReadBuffer::next() @ 0x000000000a148c7b 13. /build/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) @ 0x0000000011849fb2 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]>&)>&, 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&) @ 0x0000000011841980 15. /build/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) @ 0x000000001621208e 16. /build/src/Storages/StorageReplicatedMergeTree.cpp:5228: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl[abi:se190107] const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000015f9a5fe 17. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000015ed8bfd 18. /build/src/Storages/StorageReplicatedMergeTree.cpp:2514: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x0000000015ec9aab 19. /build/src/Storages/StorageReplicatedMergeTree.cpp:2349: DB::StorageReplicatedMergeTree::executeLogEntry(DB::ReplicatedMergeTreeLogEntry&) @ 0x0000000015eba91b 20. /build/src/Storages/StorageReplicatedMergeTree.cpp:3876: bool std::__function::__policy_invoker&)>::__call_impl[abi:se190107])::$_1, bool (std::shared_ptr&)>>(std::__function::__policy_storage const*, std::shared_ptr&) @ 0x0000000015f9837e 21. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000165d6fc3 22. /build/src/Storages/StorageReplicatedMergeTree.cpp:3872: DB::StorageReplicatedMergeTree::processQueueEntry(std::shared_ptr) @ 0x0000000015efc18a 23. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001624c1b2 24. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000162f9c70 25. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x00000000162fa55a 26. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc6653 27. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000000fccc4c3 28. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc3d92 29. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fcca080 30. ? @ 0x00007fbc6213eac3 31. ? @ 0x00007fbc621d0850 (version 25.3.6.10636.altinitytest (altinity build)) 2025.07.28 11:59:40.279528 [ 3977 ] {} test_13.rmt2 (7f9b740d-015c-470e-8cc6-8ba33be0dc63): auto DB::StorageReplicatedMergeTree::processQueueEntry(ReplicatedMergeTreeQueue::SelectedEntryPtr)::(anonymous class)::operator()(LogEntryPtr &) const: Code: 86. DB::HTTPException: Received error from remote server http://146b4357c08d:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Ftest%2F01165%2Ftest_13%2Frmt%2Freplicas%2F1&part=20250728_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.6.10636.altinitytest (altinity build)) '. (RECEIVED_ERROR_FROM_REMOTE_IO_SERVER), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.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 const&, int&&, String const&, unsigned long&&, String const&) @ 0x000000000feda8d9 4. /build/src/IO/HTTPCommon.cpp:104: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x000000000feda6e2 5. /build/src/IO/HTTPCommon.cpp:93: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x000000000feda537 6. /build/src/IO/ReadWriteBufferFromHTTP.cpp:277: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x000000001184a4c4 7. /build/src/IO/ReadWriteBufferFromHTTP.cpp:285: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x000000001184a615 8. /build/src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x000000001184ae59 9. /build/src/IO/ReadWriteBufferFromHTTP.cpp:472: void std::__function::__policy_invoker::__call_impl[abi:se190107]>(std::__function::__policy_storage const*) @ 0x000000001184cedd 10. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001184858b 11. /build/src/IO/ReadWriteBufferFromHTTP.cpp:465: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x000000001184bf0b 12. /build/src/IO/ReadBuffer.h:60: DB::ReadBuffer::next() @ 0x000000000a148c7b 13. /build/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) @ 0x0000000011849fb2 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]>&)>&, 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&) @ 0x0000000011841980 15. /build/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) @ 0x000000001621208e 16. /build/src/Storages/StorageReplicatedMergeTree.cpp:5228: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl[abi:se190107] const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000015f9a5fe 17. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000015ed8bfd 18. /build/src/Storages/StorageReplicatedMergeTree.cpp:2514: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x0000000015ec9aab 19. /build/src/Storages/StorageReplicatedMergeTree.cpp:2349: DB::StorageReplicatedMergeTree::executeLogEntry(DB::ReplicatedMergeTreeLogEntry&) @ 0x0000000015eba91b 20. /build/src/Storages/StorageReplicatedMergeTree.cpp:3876: bool std::__function::__policy_invoker&)>::__call_impl[abi:se190107])::$_1, bool (std::shared_ptr&)>>(std::__function::__policy_storage const*, std::shared_ptr&) @ 0x0000000015f9837e 21. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000165d6fc3 22. /build/src/Storages/StorageReplicatedMergeTree.cpp:3872: DB::StorageReplicatedMergeTree::processQueueEntry(std::shared_ptr) @ 0x0000000015efc18a 23. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001624c1b2 24. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000162f9c70 25. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x00000000162fa55a 26. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc6653 27. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000000fccc4c3 28. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc3d92 29. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fcca080 30. ? @ 0x00007fbc6213eac3 31. ? @ 0x00007fbc621d0850 (version 25.3.6.10636.altinitytest (altinity build)) 2025.07.28 11:59:41.064248 [ 3961 ] {} test_13.rmt2 (7f9b740d-015c-470e-8cc6-8ba33be0dc63): auto DB::StorageReplicatedMergeTree::processQueueEntry(ReplicatedMergeTreeQueue::SelectedEntryPtr)::(anonymous class)::operator()(LogEntryPtr &) const: Code: 86. DB::HTTPException: Received error from remote server http://146b4357c08d:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Ftest%2F01165%2Ftest_13%2Frmt%2Freplicas%2F1&part=20250728_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.6.10636.altinitytest (altinity build)) '. (RECEIVED_ERROR_FROM_REMOTE_IO_SERVER), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.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 const&, int&&, String const&, unsigned long&&, String const&) @ 0x000000000feda8d9 4. /build/src/IO/HTTPCommon.cpp:104: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x000000000feda6e2 5. /build/src/IO/HTTPCommon.cpp:93: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x000000000feda537 6. /build/src/IO/ReadWriteBufferFromHTTP.cpp:277: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x000000001184a4c4 7. /build/src/IO/ReadWriteBufferFromHTTP.cpp:285: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x000000001184a615 8. /build/src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x000000001184ae59 9. /build/src/IO/ReadWriteBufferFromHTTP.cpp:472: void std::__function::__policy_invoker::__call_impl[abi:se190107]>(std::__function::__policy_storage const*) @ 0x000000001184cedd 10. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001184858b 11. /build/src/IO/ReadWriteBufferFromHTTP.cpp:465: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x000000001184bf0b 12. /build/src/IO/ReadBuffer.h:60: DB::ReadBuffer::next() @ 0x000000000a148c7b 13. /build/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) @ 0x0000000011849fb2 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]>&)>&, 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&) @ 0x0000000011841980 15. /build/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) @ 0x000000001621208e 16. /build/src/Storages/StorageReplicatedMergeTree.cpp:5228: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl[abi:se190107] const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000015f9a5fe 17. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000015ed8bfd 18. /build/src/Storages/StorageReplicatedMergeTree.cpp:2514: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x0000000015ec9aab 19. /build/src/Storages/StorageReplicatedMergeTree.cpp:2349: DB::StorageReplicatedMergeTree::executeLogEntry(DB::ReplicatedMergeTreeLogEntry&) @ 0x0000000015eba91b 20. /build/src/Storages/StorageReplicatedMergeTree.cpp:3876: bool std::__function::__policy_invoker&)>::__call_impl[abi:se190107])::$_1, bool (std::shared_ptr&)>>(std::__function::__policy_storage const*, std::shared_ptr&) @ 0x0000000015f9837e 21. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000165d6fc3 22. /build/src/Storages/StorageReplicatedMergeTree.cpp:3872: DB::StorageReplicatedMergeTree::processQueueEntry(std::shared_ptr) @ 0x0000000015efc18a 23. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001624c1b2 24. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000162f9c70 25. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x00000000162fa55a 26. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc6653 27. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000000fccc4c3 28. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc3d92 29. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fcca080 30. ? @ 0x00007fbc6213eac3 31. ? @ 0x00007fbc621d0850 (version 25.3.6.10636.altinitytest (altinity build)) 2025.07.28 11:59:41.313851 [ 54078 ] {} ExternalDictionariesLoader: Could not load external dictionary 'cc8b1a52-da70-449c-9c23-8d623c5fcc44', next update is scheduled at 2025-07-28 12:05:16: Code: 396. DB::Exception: Limit for result exceeded, max bytes: 1.00 B, current bytes: 36.00 B. (TOO_MANY_ROWS_OR_BYTES), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, char const*&, ReadableSize&&, ReadableSize&&) @ 0x0000000013bd4eeb 4. /build/src/QueryPipeline/SizeLimits.cpp:43: DB::SizeLimits::check(unsigned long, unsigned long, char const*, int, int) const @ 0x0000000013bd48a1 5. /build/src/Processors/Transforms/LimitsCheckingTransform.cpp:45: DB::LimitsCheckingTransform::transform(DB::Chunk&) @ 0x0000000016c1d2fb 6. /build/src/Processors/ISimpleTransform.h:33: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000011a9a453 7. /build/src/Processors/ISimpleTransform.cpp:89: DB::ISimpleTransform::work() @ 0x000000001699fca0 8. /build/src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x00000000169bd00f 9. /build/src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x00000000169b2105 10. /build/src/Processors/Executors/PipelineExecutor.cpp:170: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x00000000169b16a7 11. /build/src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x00000000169c081c 12. /build/src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x00000000169c0978 13. /build/src/Dictionaries/FlatDictionary.cpp:502: DB::FlatDictionary::loadData() @ 0x0000000011b424cb 14. /build/src/Dictionaries/FlatDictionary.cpp:46: DB::FlatDictionary::FlatDictionary(DB::StorageID const&, DB::DictionaryStructure const&, std::shared_ptr, DB::FlatDictionary::Configuration, std::shared_ptr) @ 0x0000000011b42111 15. /build/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:se190107]> (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) @ 0x0000000011b5d3e2 16. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000012d8a61d 17. /build/src/Interpreters/ExternalDictionariesLoader.cpp:47: DB::ExternalDictionariesLoader::createObject(String const&, Poco::Util::AbstractConfiguration const&, String const&, String const&) const @ 0x00000000148a6f44 18. /build/src/Interpreters/ExternalLoader.cpp:1522: DB::ExternalLoader::LoadingDispatcher::loadSingleObject(String const&, DB::ExternalLoader::ObjectConfig const&, std::shared_ptr) @ 0x00000000148b2ee8 19. /build/src/Interpreters/ExternalLoader.cpp:998: DB::ExternalLoader::LoadingDispatcher::doLoading(String const&, unsigned long, bool, unsigned long, bool, std::shared_ptr) @ 0x00000000148b197d 20. /build/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()() @ 0x00000000148b5991 21. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc3d92 22. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fcca080 23. ? @ 0x00007fbc6213eac3 24. ? @ 0x00007fbc621d0850 (version 25.3.6.10636.altinitytest (altinity build)) 2025.07.28 11:59:41.842524 [ 3962 ] {} test_13.rmt2 (7f9b740d-015c-470e-8cc6-8ba33be0dc63): auto DB::StorageReplicatedMergeTree::processQueueEntry(ReplicatedMergeTreeQueue::SelectedEntryPtr)::(anonymous class)::operator()(LogEntryPtr &) const: Code: 86. DB::HTTPException: Received error from remote server http://146b4357c08d:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Ftest%2F01165%2Ftest_13%2Frmt%2Freplicas%2F1&part=20250728_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.6.10636.altinitytest (altinity build)) '. (RECEIVED_ERROR_FROM_REMOTE_IO_SERVER), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.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 const&, int&&, String const&, unsigned long&&, String const&) @ 0x000000000feda8d9 4. /build/src/IO/HTTPCommon.cpp:104: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x000000000feda6e2 5. /build/src/IO/HTTPCommon.cpp:93: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x000000000feda537 6. /build/src/IO/ReadWriteBufferFromHTTP.cpp:277: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x000000001184a4c4 7. /build/src/IO/ReadWriteBufferFromHTTP.cpp:285: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x000000001184a615 8. /build/src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x000000001184ae59 9. /build/src/IO/ReadWriteBufferFromHTTP.cpp:472: void std::__function::__policy_invoker::__call_impl[abi:se190107]>(std::__function::__policy_storage const*) @ 0x000000001184cedd 10. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001184858b 11. /build/src/IO/ReadWriteBufferFromHTTP.cpp:465: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x000000001184bf0b 12. /build/src/IO/ReadBuffer.h:60: DB::ReadBuffer::next() @ 0x000000000a148c7b 13. /build/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) @ 0x0000000011849fb2 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]>&)>&, 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&) @ 0x0000000011841980 15. /build/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) @ 0x000000001621208e 16. /build/src/Storages/StorageReplicatedMergeTree.cpp:5228: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl[abi:se190107] const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000015f9a5fe 17. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000015ed8bfd 18. /build/src/Storages/StorageReplicatedMergeTree.cpp:2514: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x0000000015ec9aab 19. /build/src/Storages/StorageReplicatedMergeTree.cpp:2349: DB::StorageReplicatedMergeTree::executeLogEntry(DB::ReplicatedMergeTreeLogEntry&) @ 0x0000000015eba91b 20. /build/src/Storages/StorageReplicatedMergeTree.cpp:3876: bool std::__function::__policy_invoker&)>::__call_impl[abi:se190107])::$_1, bool (std::shared_ptr&)>>(std::__function::__policy_storage const*, std::shared_ptr&) @ 0x0000000015f9837e 21. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000165d6fc3 22. /build/src/Storages/StorageReplicatedMergeTree.cpp:3872: DB::StorageReplicatedMergeTree::processQueueEntry(std::shared_ptr) @ 0x0000000015efc18a 23. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001624c1b2 24. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000162f9c70 25. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x00000000162fa55a 26. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc6653 27. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000000fccc4c3 28. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc3d92 29. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fcca080 30. ? @ 0x00007fbc6213eac3 31. ? @ 0x00007fbc621d0850 (version 25.3.6.10636.altinitytest (altinity build)) 2025.07.28 11:59:41.983870 [ 3969 ] {} test_13.rmt2 (7f9b740d-015c-470e-8cc6-8ba33be0dc63): auto DB::StorageReplicatedMergeTree::processQueueEntry(ReplicatedMergeTreeQueue::SelectedEntryPtr)::(anonymous class)::operator()(LogEntryPtr &) const: Code: 86. DB::HTTPException: Received error from remote server http://146b4357c08d:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Ftest%2F01165%2Ftest_13%2Frmt%2Freplicas%2F1&part=20250728_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.6.10636.altinitytest (altinity build)) '. (RECEIVED_ERROR_FROM_REMOTE_IO_SERVER), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.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 const&, int&&, String const&, unsigned long&&, String const&) @ 0x000000000feda8d9 4. /build/src/IO/HTTPCommon.cpp:104: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x000000000feda6e2 5. /build/src/IO/HTTPCommon.cpp:93: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x000000000feda537 6. /build/src/IO/ReadWriteBufferFromHTTP.cpp:277: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x000000001184a4c4 7. /build/src/IO/ReadWriteBufferFromHTTP.cpp:285: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x000000001184a615 8. /build/src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x000000001184ae59 9. /build/src/IO/ReadWriteBufferFromHTTP.cpp:472: void std::__function::__policy_invoker::__call_impl[abi:se190107]>(std::__function::__policy_storage const*) @ 0x000000001184cedd 10. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001184858b 11. /build/src/IO/ReadWriteBufferFromHTTP.cpp:465: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x000000001184bf0b 12. /build/src/IO/ReadBuffer.h:60: DB::ReadBuffer::next() @ 0x000000000a148c7b 13. /build/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) @ 0x0000000011849fb2 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]>&)>&, 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&) @ 0x0000000011841980 15. /build/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) @ 0x000000001621208e 16. /build/src/Storages/StorageReplicatedMergeTree.cpp:5228: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl[abi:se190107] const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000015f9a5fe 17. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000015ed8bfd 18. /build/src/Storages/StorageReplicatedMergeTree.cpp:2514: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x0000000015ec9aab 19. /build/src/Storages/StorageReplicatedMergeTree.cpp:2349: DB::StorageReplicatedMergeTree::executeLogEntry(DB::ReplicatedMergeTreeLogEntry&) @ 0x0000000015eba91b 20. /build/src/Storages/StorageReplicatedMergeTree.cpp:3876: bool std::__function::__policy_invoker&)>::__call_impl[abi:se190107])::$_1, bool (std::shared_ptr&)>>(std::__function::__policy_storage const*, std::shared_ptr&) @ 0x0000000015f9837e 21. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000165d6fc3 22. /build/src/Storages/StorageReplicatedMergeTree.cpp:3872: DB::StorageReplicatedMergeTree::processQueueEntry(std::shared_ptr) @ 0x0000000015efc18a 23. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001624c1b2 24. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000162f9c70 25. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x00000000162fa55a 26. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc6653 27. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000000fccc4c3 28. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc3d92 29. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fcca080 30. ? @ 0x00007fbc6213eac3 31. ? @ 0x00007fbc621d0850 (version 25.3.6.10636.altinitytest (altinity build)) 2025.07.28 11:59:42.413049 [ 3967 ] {} test_13.rmt2 (7f9b740d-015c-470e-8cc6-8ba33be0dc63): auto DB::StorageReplicatedMergeTree::processQueueEntry(ReplicatedMergeTreeQueue::SelectedEntryPtr)::(anonymous class)::operator()(LogEntryPtr &) const: Code: 86. DB::HTTPException: Received error from remote server http://146b4357c08d:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Ftest%2F01165%2Ftest_13%2Frmt%2Freplicas%2F1&part=20250728_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.6.10636.altinitytest (altinity build)) '. (RECEIVED_ERROR_FROM_REMOTE_IO_SERVER), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.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 const&, int&&, String const&, unsigned long&&, String const&) @ 0x000000000feda8d9 4. /build/src/IO/HTTPCommon.cpp:104: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x000000000feda6e2 5. /build/src/IO/HTTPCommon.cpp:93: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x000000000feda537 6. /build/src/IO/ReadWriteBufferFromHTTP.cpp:277: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x000000001184a4c4 7. /build/src/IO/ReadWriteBufferFromHTTP.cpp:285: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x000000001184a615 8. /build/src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x000000001184ae59 9. /build/src/IO/ReadWriteBufferFromHTTP.cpp:472: void std::__function::__policy_invoker::__call_impl[abi:se190107]>(std::__function::__policy_storage const*) @ 0x000000001184cedd 10. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001184858b 11. /build/src/IO/ReadWriteBufferFromHTTP.cpp:465: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x000000001184bf0b 12. /build/src/IO/ReadBuffer.h:60: DB::ReadBuffer::next() @ 0x000000000a148c7b 13. /build/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) @ 0x0000000011849fb2 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]>&)>&, 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&) @ 0x0000000011841980 15. /build/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) @ 0x000000001621208e 16. /build/src/Storages/StorageReplicatedMergeTree.cpp:5228: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl[abi:se190107] const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000015f9a5fe 17. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000015ed8bfd 18. /build/src/Storages/StorageReplicatedMergeTree.cpp:2514: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x0000000015ec9aab 19. /build/src/Storages/StorageReplicatedMergeTree.cpp:2349: DB::StorageReplicatedMergeTree::executeLogEntry(DB::ReplicatedMergeTreeLogEntry&) @ 0x0000000015eba91b 20. /build/src/Storages/StorageReplicatedMergeTree.cpp:3876: bool std::__function::__policy_invoker&)>::__call_impl[abi:se190107])::$_1, bool (std::shared_ptr&)>>(std::__function::__policy_storage const*, std::shared_ptr&) @ 0x0000000015f9837e 21. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000165d6fc3 22. /build/src/Storages/StorageReplicatedMergeTree.cpp:3872: DB::StorageReplicatedMergeTree::processQueueEntry(std::shared_ptr) @ 0x0000000015efc18a 23. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001624c1b2 24. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000162f9c70 25. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x00000000162fa55a 26. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc6653 27. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000000fccc4c3 28. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc3d92 29. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fcca080 30. ? @ 0x00007fbc6213eac3 31. ? @ 0x00007fbc621d0850 (version 25.3.6.10636.altinitytest (altinity build)) 2025.07.28 11:59:42.502938 [ 3976 ] {} test_13.rmt2 (7f9b740d-015c-470e-8cc6-8ba33be0dc63): auto DB::StorageReplicatedMergeTree::processQueueEntry(ReplicatedMergeTreeQueue::SelectedEntryPtr)::(anonymous class)::operator()(LogEntryPtr &) const: Code: 86. DB::HTTPException: Received error from remote server http://146b4357c08d:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Ftest%2F01165%2Ftest_13%2Frmt%2Freplicas%2F1&part=20250728_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.6.10636.altinitytest (altinity build)) '. (RECEIVED_ERROR_FROM_REMOTE_IO_SERVER), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.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 const&, int&&, String const&, unsigned long&&, String const&) @ 0x000000000feda8d9 4. /build/src/IO/HTTPCommon.cpp:104: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x000000000feda6e2 5. /build/src/IO/HTTPCommon.cpp:93: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x000000000feda537 6. /build/src/IO/ReadWriteBufferFromHTTP.cpp:277: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x000000001184a4c4 7. /build/src/IO/ReadWriteBufferFromHTTP.cpp:285: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x000000001184a615 8. /build/src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x000000001184ae59 9. /build/src/IO/ReadWriteBufferFromHTTP.cpp:472: void std::__function::__policy_invoker::__call_impl[abi:se190107]>(std::__function::__policy_storage const*) @ 0x000000001184cedd 10. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001184858b 11. /build/src/IO/ReadWriteBufferFromHTTP.cpp:465: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x000000001184bf0b 12. /build/src/IO/ReadBuffer.h:60: DB::ReadBuffer::next() @ 0x000000000a148c7b 13. /build/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) @ 0x0000000011849fb2 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]>&)>&, 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&) @ 0x0000000011841980 15. /build/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) @ 0x000000001621208e 16. /build/src/Storages/StorageReplicatedMergeTree.cpp:5228: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl[abi:se190107] const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000015f9a5fe 17. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000015ed8bfd 18. /build/src/Storages/StorageReplicatedMergeTree.cpp:2514: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x0000000015ec9aab 19. /build/src/Storages/StorageReplicatedMergeTree.cpp:2349: DB::StorageReplicatedMergeTree::executeLogEntry(DB::ReplicatedMergeTreeLogEntry&) @ 0x0000000015eba91b 20. /build/src/Storages/StorageReplicatedMergeTree.cpp:3876: bool std::__function::__policy_invoker&)>::__call_impl[abi:se190107])::$_1, bool (std::shared_ptr&)>>(std::__function::__policy_storage const*, std::shared_ptr&) @ 0x0000000015f9837e 21. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000165d6fc3 22. /build/src/Storages/StorageReplicatedMergeTree.cpp:3872: DB::StorageReplicatedMergeTree::processQueueEntry(std::shared_ptr) @ 0x0000000015efc18a 23. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001624c1b2 24. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000162f9c70 25. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x00000000162fa55a 26. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc6653 27. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000000fccc4c3 28. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc3d92 29. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fcca080 30. ? @ 0x00007fbc6213eac3 31. ? @ 0x00007fbc621d0850 (version 25.3.6.10636.altinitytest (altinity build)) 2025.07.28 11:59:43.286957 [ 3977 ] {} test_13.rmt2 (7f9b740d-015c-470e-8cc6-8ba33be0dc63): auto DB::StorageReplicatedMergeTree::processQueueEntry(ReplicatedMergeTreeQueue::SelectedEntryPtr)::(anonymous class)::operator()(LogEntryPtr &) const: Code: 86. DB::HTTPException: Received error from remote server http://146b4357c08d:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Ftest%2F01165%2Ftest_13%2Frmt%2Freplicas%2F1&part=20250728_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.6.10636.altinitytest (altinity build)) '. (RECEIVED_ERROR_FROM_REMOTE_IO_SERVER), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.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 const&, int&&, String const&, unsigned long&&, String const&) @ 0x000000000feda8d9 4. /build/src/IO/HTTPCommon.cpp:104: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x000000000feda6e2 5. /build/src/IO/HTTPCommon.cpp:93: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x000000000feda537 6. /build/src/IO/ReadWriteBufferFromHTTP.cpp:277: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x000000001184a4c4 7. /build/src/IO/ReadWriteBufferFromHTTP.cpp:285: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x000000001184a615 8. /build/src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x000000001184ae59 9. /build/src/IO/ReadWriteBufferFromHTTP.cpp:472: void std::__function::__policy_invoker::__call_impl[abi:se190107]>(std::__function::__policy_storage const*) @ 0x000000001184cedd 10. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001184858b 11. /build/src/IO/ReadWriteBufferFromHTTP.cpp:465: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x000000001184bf0b 12. /build/src/IO/ReadBuffer.h:60: DB::ReadBuffer::next() @ 0x000000000a148c7b 13. /build/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) @ 0x0000000011849fb2 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]>&)>&, 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&) @ 0x0000000011841980 15. /build/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) @ 0x000000001621208e 16. /build/src/Storages/StorageReplicatedMergeTree.cpp:5228: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl[abi:se190107] const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000015f9a5fe 17. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000015ed8bfd 18. /build/src/Storages/StorageReplicatedMergeTree.cpp:2514: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x0000000015ec9aab 19. /build/src/Storages/StorageReplicatedMergeTree.cpp:2349: DB::StorageReplicatedMergeTree::executeLogEntry(DB::ReplicatedMergeTreeLogEntry&) @ 0x0000000015eba91b 20. /build/src/Storages/StorageReplicatedMergeTree.cpp:3876: bool std::__function::__policy_invoker&)>::__call_impl[abi:se190107])::$_1, bool (std::shared_ptr&)>>(std::__function::__policy_storage const*, std::shared_ptr&) @ 0x0000000015f9837e 21. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000165d6fc3 22. /build/src/Storages/StorageReplicatedMergeTree.cpp:3872: DB::StorageReplicatedMergeTree::processQueueEntry(std::shared_ptr) @ 0x0000000015efc18a 23. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001624c1b2 24. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000162f9c70 25. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x00000000162fa55a 26. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc6653 27. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000000fccc4c3 28. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc3d92 29. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fcca080 30. ? @ 0x00007fbc6213eac3 31. ? @ 0x00007fbc621d0850 (version 25.3.6.10636.altinitytest (altinity build)) 2025.07.28 11:59:43.458467 [ 17256 ] {cc41d7a9-1452-4932-8efe-87c983638f79} executeQuery: Code: 80. DB::Exception: Cannot CREATE a table AS test_uz20hnqr.v, it is a View. (INCORRECT_QUERY) (version 25.3.6.10636.altinitytest (altinity build)) (from [::1]:38924) (comment: 01056_create_table_as.sql) (query 16, line 20) (in query: CREATE TABLE t3 AS v;), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000a9b78ab 4. /build/src/Interpreters/InterpreterCreateQuery.cpp:1340: DB::InterpreterCreateQuery::setEngine(DB::ASTCreateQuery&) const @ 0x00000000148f3241 5. /build/src/Interpreters/InterpreterCreateQuery.cpp:761: DB::InterpreterCreateQuery::getTablePropertiesAndNormalizeCreateQuery(DB::ASTCreateQuery&, DB::LoadingStrictnessLevel) const @ 0x00000000148edf8c 6. /build/src/Interpreters/InterpreterCreateQuery.cpp:1657: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000148f901b 7. /build/src/Interpreters/InterpreterCreateQuery.cpp:2352: DB::InterpreterCreateQuery::execute() @ 0x0000000014905a41 8. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88dc9 9. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 10. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 11. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 12. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 13. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 14. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 15. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 16. ? @ 0x00007fbc6213eac3 17. ? @ 0x00007fbc621d0850 2025.07.28 11:59:43.461871 [ 17256 ] {} TCPHandler: Code: 80. DB::Exception: Cannot CREATE a table AS test_uz20hnqr.v, it is a View. (INCORRECT_QUERY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000a9b78ab 4. /build/src/Interpreters/InterpreterCreateQuery.cpp:1340: DB::InterpreterCreateQuery::setEngine(DB::ASTCreateQuery&) const @ 0x00000000148f3241 5. /build/src/Interpreters/InterpreterCreateQuery.cpp:761: DB::InterpreterCreateQuery::getTablePropertiesAndNormalizeCreateQuery(DB::ASTCreateQuery&, DB::LoadingStrictnessLevel) const @ 0x00000000148edf8c 6. /build/src/Interpreters/InterpreterCreateQuery.cpp:1657: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000148f901b 7. /build/src/Interpreters/InterpreterCreateQuery.cpp:2352: DB::InterpreterCreateQuery::execute() @ 0x0000000014905a41 8. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88dc9 9. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 10. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 11. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 12. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 13. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 14. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 15. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 16. ? @ 0x00007fbc6213eac3 17. ? @ 0x00007fbc621d0850 2025.07.28 11:59:44.031633 [ 17256 ] {3808dcfd-2091-48f1-803f-c43980ea0652} executeQuery: Code: 80. DB::Exception: Cannot CREATE a table AS test_uz20hnqr.dict, it is a Dictionary. (INCORRECT_QUERY) (version 25.3.6.10636.altinitytest (altinity build)) (from [::1]:38924) (comment: 01056_create_table_as.sql) (query 23, line 39) (in query: CREATE TABLE t3 AS dict;), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000a9b78ab 4. /build/src/Interpreters/InterpreterCreateQuery.cpp:1358: DB::InterpreterCreateQuery::setEngine(DB::ASTCreateQuery&) const @ 0x00000000148f36bf 5. /build/src/Interpreters/InterpreterCreateQuery.cpp:761: DB::InterpreterCreateQuery::getTablePropertiesAndNormalizeCreateQuery(DB::ASTCreateQuery&, DB::LoadingStrictnessLevel) const @ 0x00000000148edf8c 6. /build/src/Interpreters/InterpreterCreateQuery.cpp:1657: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000148f901b 7. /build/src/Interpreters/InterpreterCreateQuery.cpp:2352: DB::InterpreterCreateQuery::execute() @ 0x0000000014905a41 8. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88dc9 9. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 10. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 11. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 12. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 13. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 14. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 15. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 16. ? @ 0x00007fbc6213eac3 17. ? @ 0x00007fbc621d0850 2025.07.28 11:59:44.039489 [ 17256 ] {} TCPHandler: Code: 80. DB::Exception: Cannot CREATE a table AS test_uz20hnqr.dict, it is a Dictionary. (INCORRECT_QUERY), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000a9b78ab 4. /build/src/Interpreters/InterpreterCreateQuery.cpp:1358: DB::InterpreterCreateQuery::setEngine(DB::ASTCreateQuery&) const @ 0x00000000148f36bf 5. /build/src/Interpreters/InterpreterCreateQuery.cpp:761: DB::InterpreterCreateQuery::getTablePropertiesAndNormalizeCreateQuery(DB::ASTCreateQuery&, DB::LoadingStrictnessLevel) const @ 0x00000000148edf8c 6. /build/src/Interpreters/InterpreterCreateQuery.cpp:1657: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000148f901b 7. /build/src/Interpreters/InterpreterCreateQuery.cpp:2352: DB::InterpreterCreateQuery::execute() @ 0x0000000014905a41 8. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88dc9 9. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 10. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 11. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 12. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 13. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 14. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 15. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 16. ? @ 0x00007fbc6213eac3 17. ? @ 0x00007fbc621d0850 2025.07.28 11:59:44.046330 [ 3401 ] {} test_15.replicated_summing_merge_tree_with_list_of_columns_to_sum (ReplicatedMergeTreeRestartingThread): ZooKeeper session has expired. Switching to a new session. 2025.07.28 11:59:44.047480 [ 3577 ] {} test_3.test_03217_merge_replica_1 (ReplicatedMergeTreeRestartingThread): ZooKeeper session has expired. Switching to a new session. 2025.07.28 11:59:44.049026 [ 3510 ] {} test_1.t_json_3 (ReplicatedMergeTreeRestartingThread): ZooKeeper session has expired. Switching to a new session. 2025.07.28 11:59:44.050379 [ 3294 ] {} test_13.rmt1 (ReplicatedMergeTreeRestartingThread): ZooKeeper session has expired. Switching to a new session. 2025.07.28 11:59:44.058214 [ 3295 ] {} test_15.replicated_aggregating_merge_tree_with_sampling (ReplicatedMergeTreeRestartingThread): ZooKeeper session has expired. Switching to a new session. 2025.07.28 11:59:44.059710 [ 3706 ] {} test_15.replicated_summing_merge_tree (ReplicatedMergeTreeRestartingThread): ZooKeeper session has expired. Switching to a new session. 2025.07.28 11:59:44.064629 [ 3307 ] {} test_3.test_03217_merge_replica_2 (ReplicatedMergeTreeRestartingThread): ZooKeeper session has expired. Switching to a new session. 2025.07.28 11:59:44.066238 [ 3407 ] {} test_1.replicated_table_r1 (ReplicatedMergeTreeRestartingThread): ZooKeeper session has expired. Switching to a new session. 2025.07.28 11:59:44.072835 [ 3735 ] {} test_13.rmt2 (ReplicatedMergeTreeRestartingThread): ZooKeeper session has expired. Switching to a new session. 2025.07.28 11:59:44.081782 [ 3551 ] {} test_1.test_alter_decimal (ReplicatedMergeTreeRestartingThread): ZooKeeper session has expired. Switching to a new session. 2025.07.28 11:59:44.096727 [ 3720 ] {} test_15.replicated_versioned_collapsing_merge_tree (ReplicatedMergeTreeRestartingThread): ZooKeeper session has expired. Switching to a new session. 2025.07.28 11:59:44.101947 [ 3548 ] {} test_1.replicated_table_r2 (ReplicatedMergeTreeRestartingThread): ZooKeeper session has expired. Switching to a new session. 2025.07.28 11:59:45.174595 [ 33890 ] {} 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. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: Coordination::Exception::Exception(T&&, Coordination::Error) @ 0x000000001660315b 3. /build/src/Common/ZooKeeper/KeeperException.h:58: Coordination::Exception Coordination::Exception::fromMessage(Coordination::Error, T&&) @ 0x00000000171a88d0 4. /build/src/Common/ZooKeeper/ZooKeeperImpl.cpp:1795: Coordination::ZooKeeper::maybeInjectRecvFault() @ 0x00000000171a20f1 5. /build/src/Common/ZooKeeper/ZooKeeperImpl.cpp:928: Coordination::ZooKeeper::receiveEvent() @ 0x00000000171a115e 6. /build/src/Common/ZooKeeper/ZooKeeperImpl.cpp:875: Coordination::ZooKeeper::receiveThread() @ 0x00000000171a0898 7. /build/src/Common/ZooKeeper/ZooKeeperImpl.cpp:452: void std::__function::__policy_invoker::__call_impl[abi:se190107]::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*) @ 0x00000000171a778a 8. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc3d92 9. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fcca080 10. ? @ 0x00007fbc6213eac3 11. ? @ 0x00007fbc621d0850 Job's origin stack trace: 0. /build/src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000000fc33b84 1. /build/src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000000fcc2ea7 2. /build/src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fcc535c 3. /build/src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000000fcc584d 4. /build/src/Common/ThreadPool.h:279: Coordination::ZooKeeper::ZooKeeper(std::vector> const&, zkutil::ZooKeeperArgs const&, std::shared_ptr) @ 0x00000000171993a4 5. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: zkutil::ZooKeeper::init(zkutil::ZooKeeperArgs, std::unique_ptr>) @ 0x0000000017139f9d 6. /build/src/Common/ZooKeeper/ZooKeeper.cpp:235: zkutil::ZooKeeper::ZooKeeper(zkutil::ZooKeeperArgs const&, std::shared_ptr, std::vector>, std::unique_ptr>) @ 0x000000001713cc06 7. /build/src/Common/ZooKeeper/ZooKeeper.cpp:1133: zkutil::ZooKeeper::startNewSession() const @ 0x0000000017147842 8. /build/src/Interpreters/Context.cpp:4043: DB::Context::getZooKeeper() const @ 0x000000001443fb0b 9. /build/src/Storages/StorageReplicatedMergeTree.cpp:304: DB::StorageReplicatedMergeTree::setZooKeeper() @ 0x0000000015e85e11 10. /build/src/Storages/MergeTree/ReplicatedMergeTreeRestartingThread.cpp:147: DB::ReplicatedMergeTreeRestartingThread::runImpl() @ 0x00000000165e8ae4 11. /build/src/Storages/MergeTree/ReplicatedMergeTreeRestartingThread.cpp:86: DB::ReplicatedMergeTreeRestartingThread::run() @ 0x00000000165e803e 12. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000139630d4 13. /build/src/Core/BackgroundSchedulePool.cpp:308: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001396616a 14. /build/src/Core/BackgroundSchedulePool.cpp:171: void std::__function::__policy_invoker::__call_impl[abi:se190107]::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_1>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_1&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001396690a 15. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc3d92 16. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fcca080 17. ? @ 0x00007fbc6213eac3 18. ? @ 0x00007fbc621d0850 (version 25.3.6.10636.altinitytest (altinity build)) 2025.07.28 11:59:45.210565 [ 3665 ] {} test_15.replicated_summing_merge_tree_with_list_of_columns_to_sum (ReplicatedMergeTreeRestartingThread): ZooKeeper session has expired. Switching to a new session. 2025.07.28 11:59:45.211685 [ 3591 ] {} test_3.test_03217_merge_replica_1 (ReplicatedMergeTreeRestartingThread): ZooKeeper session has expired. Switching to a new session. 2025.07.28 11:59:45.224800 [ 3545 ] {} test_1.t_json_3 (ReplicatedMergeTreeRestartingThread): ZooKeeper session has expired. Switching to a new session. 2025.07.28 11:59:45.226239 [ 3614 ] {} test_13.rmt1 (ReplicatedMergeTreeRestartingThread): ZooKeeper session has expired. Switching to a new session. 2025.07.28 11:59:45.227989 [ 3514 ] {} test_15.replicated_aggregating_merge_tree_with_sampling (ReplicatedMergeTreeRestartingThread): ZooKeeper session has expired. Switching to a new session. 2025.07.28 11:59:45.229245 [ 3302 ] {} test_15.replicated_summing_merge_tree (ReplicatedMergeTreeRestartingThread): ZooKeeper session has expired. Switching to a new session. 2025.07.28 11:59:45.231344 [ 3592 ] {} test_3.test_03217_merge_replica_2 (ReplicatedMergeTreeRestartingThread): ZooKeeper session has expired. Switching to a new session. 2025.07.28 11:59:45.262357 [ 3582 ] {} test_1.test_alter_decimal (ReplicatedMergeTreeRestartingThread): ZooKeeper session has expired. Switching to a new session. 2025.07.28 11:59:45.264655 [ 3362 ] {} test_15.replicated_versioned_collapsing_merge_tree (ReplicatedMergeTreeRestartingThread): ZooKeeper session has expired. Switching to a new session. 2025.07.28 11:59:45.270397 [ 3762 ] {} test_1.replicated_table_r2 (ReplicatedMergeTreeRestartingThread): ZooKeeper session has expired. Switching to a new session. 2025.07.28 11:59:45.271529 [ 3604 ] {} test_1.replicated_table_r1 (ReplicatedMergeTreeRestartingThread): ZooKeeper session has expired. Switching to a new session. 2025.07.28 11:59:45.310785 [ 3686 ] {} test_1.t_json_3 (3bf9aa72-36fd-4f8e-8909-a3e4d98386b4): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 999. Coordination::Exception: Coordination error: Connection loss, path /clickhouse/tables/test_1/test_01825_3/t_json_3/log. (KEEPER_EXCEPTION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, char const*&&, String const&) @ 0x000000000ba4e10b 4. /build/src/Common/ZooKeeper/KeeperException.h:37: Coordination::Exception::fromPath(Coordination::Error, String const&) @ 0x000000000ba4daab 5. /build/src/Common/ZooKeeper/ZooKeeper.cpp:377: zkutil::ZooKeeper::tryGetChildrenWatch(String const&, std::vector>&, Coordination::Stat*, std::shared_ptr>, Coordination::ListRequestType) @ 0x000000001713de51 6. /build/src/Common/ZooKeeper/ZooKeeper.cpp:362: zkutil::ZooKeeper::getChildrenWatch(String const&, Coordination::Stat*, std::function, Coordination::ListRequestType) @ 0x000000001713daed 7. /build/src/Storages/MergeTree/ReplicatedMergeTreeQueue.cpp:647: DB::ReplicatedMergeTreeQueue::pullLogsToQueue(std::shared_ptr, std::function, DB::ReplicatedMergeTreeQueue::PullLogsReason) @ 0x00000000165c12fc 8. /build/src/Storages/StorageReplicatedMergeTree.cpp:3798: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x0000000015efbaeb 9. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000139630d4 10. /build/src/Core/BackgroundSchedulePool.cpp:308: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001396616a 11. /build/src/Core/BackgroundSchedulePool.cpp:171: void std::__function::__policy_invoker::__call_impl[abi:se190107]::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_1>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_1&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001396690a 12. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc3d92 13. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fcca080 14. ? @ 0x00007fbc6213eac3 15. ? @ 0x00007fbc621d0850 (version 25.3.6.10636.altinitytest (altinity build)) 2025.07.28 11:59:45.326794 [ 3563 ] {} test_3.test_03217_merge_replica_1 (3e2f6baa-967c-4f24-9f8c-b72516237951): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 999. Coordination::Exception: Coordination error: Connection loss, path /clickhouse/tables/test_3/test_03217_merge_replica/replicas/r1/log_pointer. (KEEPER_EXCEPTION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, char const*&&, String const&) @ 0x000000000ba4e10b 4. /build/src/Common/ZooKeeper/KeeperException.h:37: Coordination::Exception::fromPath(Coordination::Error, String const&) @ 0x000000000ba4daab 5. /build/src/Common/ZooKeeper/ZooKeeper.cpp:696: zkutil::ZooKeeper::tryGetWatch(String const&, String&, Coordination::Stat*, std::function, Coordination::Error*) @ 0x0000000017141a56 6. /build/src/Common/ZooKeeper/ZooKeeper.cpp:664: zkutil::ZooKeeper::tryGet(String const&, String&, Coordination::Stat*, std::shared_ptr const&, Coordination::Error*) @ 0x0000000017141736 7. /build/src/Common/ZooKeeper/ZooKeeper.cpp:633: zkutil::ZooKeeper::get(String const&, Coordination::Stat*, std::shared_ptr const&) @ 0x0000000017141598 8. /build/src/Storages/MergeTree/ReplicatedMergeTreeQueue.cpp:640: DB::ReplicatedMergeTreeQueue::pullLogsToQueue(std::shared_ptr, std::function, DB::ReplicatedMergeTreeQueue::PullLogsReason) @ 0x00000000165c0e56 9. /build/src/Storages/StorageReplicatedMergeTree.cpp:3798: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x0000000015efbaeb 10. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000139630d4 11. /build/src/Core/BackgroundSchedulePool.cpp:308: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001396616a 12. /build/src/Core/BackgroundSchedulePool.cpp:171: void std::__function::__policy_invoker::__call_impl[abi:se190107]::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_1>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_1&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001396690a 13. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc3d92 14. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fcca080 15. ? @ 0x00007fbc6213eac3 16. ? @ 0x00007fbc621d0850 (version 25.3.6.10636.altinitytest (altinity build)) 2025.07.28 11:59:45.343211 [ 3463 ] {} test_1.test_alter_decimal (e1efba38-8aaa-4432-b90c-b2d13331b772): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 999. Coordination::Exception: Coordination error: Connection loss, path /clickhouse/test_1/01761_alter_decimal_zookeeper/log. (KEEPER_EXCEPTION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, char const*&&, String const&) @ 0x000000000ba4e10b 4. /build/src/Common/ZooKeeper/KeeperException.h:37: Coordination::Exception::fromPath(Coordination::Error, String const&) @ 0x000000000ba4daab 5. /build/src/Common/ZooKeeper/ZooKeeper.cpp:696: zkutil::ZooKeeper::tryGetWatch(String const&, String&, Coordination::Stat*, std::function, Coordination::Error*) @ 0x0000000017141a56 6. /build/src/Common/ZooKeeper/ZooKeeper.cpp:664: zkutil::ZooKeeper::tryGet(String const&, String&, Coordination::Stat*, std::shared_ptr const&, Coordination::Error*) @ 0x0000000017141736 7. /build/src/Common/ZooKeeper/ZooKeeper.cpp:633: zkutil::ZooKeeper::get(String const&, Coordination::Stat*, std::shared_ptr const&) @ 0x0000000017141598 8. /build/src/Storages/MergeTree/ReplicatedMergeTreeQueue.cpp:645: DB::ReplicatedMergeTreeQueue::pullLogsToQueue(std::shared_ptr, std::function, DB::ReplicatedMergeTreeQueue::PullLogsReason) @ 0x00000000165c10f7 9. /build/src/Storages/StorageReplicatedMergeTree.cpp:3798: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x0000000015efbaeb 10. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000139630d4 11. /build/src/Core/BackgroundSchedulePool.cpp:308: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001396616a 12. /build/src/Core/BackgroundSchedulePool.cpp:171: void std::__function::__policy_invoker::__call_impl[abi:se190107]::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_1>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_1&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001396690a 13. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc3d92 14. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fcca080 15. ? @ 0x00007fbc6213eac3 16. ? @ 0x00007fbc621d0850 (version 25.3.6.10636.altinitytest (altinity build)) 2025.07.28 11:59:45.344059 [ 3333 ] {} test_15.replicated_summing_merge_tree_with_list_of_columns_to_sum (94502ea4-47de-4ea8-9f90-fee87d04e83c): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 999. Coordination::Exception: Coordination error: Connection loss, path /clickhouse/tables/test_15/test_00083/01/replicated_summing_merge_tree_with_list_of_columns_to_sum/log. (KEEPER_EXCEPTION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, char const*&&, String const&) @ 0x000000000ba4e10b 4. /build/src/Common/ZooKeeper/KeeperException.h:37: Coordination::Exception::fromPath(Coordination::Error, String const&) @ 0x000000000ba4daab 5. /build/src/Common/ZooKeeper/ZooKeeper.cpp:696: zkutil::ZooKeeper::tryGetWatch(String const&, String&, Coordination::Stat*, std::function, Coordination::Error*) @ 0x0000000017141a56 6. /build/src/Common/ZooKeeper/ZooKeeper.cpp:664: zkutil::ZooKeeper::tryGet(String const&, String&, Coordination::Stat*, std::shared_ptr const&, Coordination::Error*) @ 0x0000000017141736 7. /build/src/Common/ZooKeeper/ZooKeeper.cpp:633: zkutil::ZooKeeper::get(String const&, Coordination::Stat*, std::shared_ptr const&) @ 0x0000000017141598 8. /build/src/Storages/MergeTree/ReplicatedMergeTreeQueue.cpp:645: DB::ReplicatedMergeTreeQueue::pullLogsToQueue(std::shared_ptr, std::function, DB::ReplicatedMergeTreeQueue::PullLogsReason) @ 0x00000000165c10f7 9. /build/src/Storages/StorageReplicatedMergeTree.cpp:3798: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x0000000015efbaeb 10. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000139630d4 11. /build/src/Core/BackgroundSchedulePool.cpp:308: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001396616a 12. /build/src/Core/BackgroundSchedulePool.cpp:171: void std::__function::__policy_invoker::__call_impl[abi:se190107]::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_1>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_1&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001396690a 13. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc3d92 14. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fcca080 15. ? @ 0x00007fbc6213eac3 16. ? @ 0x00007fbc621d0850 (version 25.3.6.10636.altinitytest (altinity build)) 2025.07.28 11:59:45.347024 [ 3465 ] {} test_15.replicated_versioned_collapsing_merge_tree (5116b6b0-ef87-4d14-8e12-37066fe15e61): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 999. Coordination::Exception: Coordination error: Connection loss, path /clickhouse/tables/test_15/test_00083/01/replicated_versioned_collapsing_merge_tree/log. (KEEPER_EXCEPTION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, char const*&&, String const&) @ 0x000000000ba4e10b 4. /build/src/Common/ZooKeeper/KeeperException.h:37: Coordination::Exception::fromPath(Coordination::Error, String const&) @ 0x000000000ba4daab 5. /build/src/Common/ZooKeeper/ZooKeeper.cpp:696: zkutil::ZooKeeper::tryGetWatch(String const&, String&, Coordination::Stat*, std::function, Coordination::Error*) @ 0x0000000017141a56 6. /build/src/Common/ZooKeeper/ZooKeeper.cpp:664: zkutil::ZooKeeper::tryGet(String const&, String&, Coordination::Stat*, std::shared_ptr const&, Coordination::Error*) @ 0x0000000017141736 7. /build/src/Common/ZooKeeper/ZooKeeper.cpp:633: zkutil::ZooKeeper::get(String const&, Coordination::Stat*, std::shared_ptr const&) @ 0x0000000017141598 8. /build/src/Storages/MergeTree/ReplicatedMergeTreeQueue.cpp:645: DB::ReplicatedMergeTreeQueue::pullLogsToQueue(std::shared_ptr, std::function, DB::ReplicatedMergeTreeQueue::PullLogsReason) @ 0x00000000165c10f7 9. /build/src/Storages/StorageReplicatedMergeTree.cpp:3798: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x0000000015efbaeb 10. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000139630d4 11. /build/src/Core/BackgroundSchedulePool.cpp:308: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001396616a 12. /build/src/Core/BackgroundSchedulePool.cpp:171: void std::__function::__policy_invoker::__call_impl[abi:se190107]::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_1>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_1&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001396690a 13. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc3d92 14. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fcca080 15. ? @ 0x00007fbc6213eac3 16. ? @ 0x00007fbc621d0850 (version 25.3.6.10636.altinitytest (altinity build)) 2025.07.28 11:59:45.353832 [ 3622 ] {} test_15.replicated_summing_merge_tree_with_list_of_columns_to_sum (ReplicatedMergeTreeCleanupThread): void DB::ReplicatedMergeTreeCleanupThread::run(): Code: 999. Coordination::Exception: Coordination error: Connection loss, path /clickhouse/tables/test_15/test_00083/01/replicated_summing_merge_tree_with_list_of_columns_to_sum/blocks. (KEEPER_EXCEPTION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, char const*&&, String const&) @ 0x000000000ba4e10b 4. /build/src/Common/ZooKeeper/KeeperException.h:37: Coordination::Exception::fromPath(Coordination::Error, String const&) @ 0x000000000ba4daab 5. /build/src/Common/ZooKeeper/ZooKeeper.cpp:377: zkutil::ZooKeeper::tryGetChildrenWatch(String const&, std::vector>&, Coordination::Stat*, std::shared_ptr>, Coordination::ListRequestType) @ 0x000000001713de51 6. /build/src/Common/ZooKeeper/ZooKeeper.cpp:347: zkutil::ZooKeeper::tryGetChildren(String const&, std::vector>&, Coordination::Stat*, std::shared_ptr const&, Coordination::ListRequestType) @ 0x000000001713d9b3 7. /build/src/Storages/MergeTree/ReplicatedMergeTreeCleanupThread.cpp:547: DB::ReplicatedMergeTreeCleanupThread::getBlocksSortedByTime(String const&, zkutil::ZooKeeper&, std::vector>&, std::map, std::less, std::allocator>>>&) @ 0x000000001659a909 8. /build/src/Storages/MergeTree/ReplicatedMergeTreeCleanupThread.cpp:477: DB::ReplicatedMergeTreeCleanupThread::clearOldBlocks(String const&, unsigned long, unsigned long, std::map, std::less, std::allocator>>>&) @ 0x00000000165960f8 9. /build/src/Storages/MergeTree/ReplicatedMergeTreeCleanupThread.cpp:194: DB::ReplicatedMergeTreeCleanupThread::iterate() @ 0x00000000165924c4 10. /build/src/Storages/MergeTree/ReplicatedMergeTreeCleanupThread.cpp:68: DB::ReplicatedMergeTreeCleanupThread::run() @ 0x00000000165913b3 11. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000139630d4 12. /build/src/Core/BackgroundSchedulePool.cpp:308: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001396616a 13. /build/src/Core/BackgroundSchedulePool.cpp:171: void std::__function::__policy_invoker::__call_impl[abi:se190107]::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_1>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_1&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001396690a 14. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc3d92 15. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fcca080 16. ? @ 0x00007fbc6213eac3 17. ? @ 0x00007fbc621d0850 (version 25.3.6.10636.altinitytest (altinity build)) 2025.07.28 11:59:45.355651 [ 3785 ] {} test_15.replicated_versioned_collapsing_merge_tree (ReplicatedMergeTreeCleanupThread): void DB::ReplicatedMergeTreeCleanupThread::run(): Code: 999. Coordination::Exception: Coordination error: Connection loss, path /clickhouse/tables/test_15/test_00083/01/replicated_versioned_collapsing_merge_tree/blocks. (KEEPER_EXCEPTION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, char const*&&, String const&) @ 0x000000000ba4e10b 4. /build/src/Common/ZooKeeper/KeeperException.h:37: Coordination::Exception::fromPath(Coordination::Error, String const&) @ 0x000000000ba4daab 5. /build/src/Common/ZooKeeper/ZooKeeper.cpp:377: zkutil::ZooKeeper::tryGetChildrenWatch(String const&, std::vector>&, Coordination::Stat*, std::shared_ptr>, Coordination::ListRequestType) @ 0x000000001713de51 6. /build/src/Common/ZooKeeper/ZooKeeper.cpp:347: zkutil::ZooKeeper::tryGetChildren(String const&, std::vector>&, Coordination::Stat*, std::shared_ptr const&, Coordination::ListRequestType) @ 0x000000001713d9b3 7. /build/src/Storages/MergeTree/ReplicatedMergeTreeCleanupThread.cpp:547: DB::ReplicatedMergeTreeCleanupThread::getBlocksSortedByTime(String const&, zkutil::ZooKeeper&, std::vector>&, std::map, std::less, std::allocator>>>&) @ 0x000000001659a909 8. /build/src/Storages/MergeTree/ReplicatedMergeTreeCleanupThread.cpp:477: DB::ReplicatedMergeTreeCleanupThread::clearOldBlocks(String const&, unsigned long, unsigned long, std::map, std::less, std::allocator>>>&) @ 0x00000000165960f8 9. /build/src/Storages/MergeTree/ReplicatedMergeTreeCleanupThread.cpp:194: DB::ReplicatedMergeTreeCleanupThread::iterate() @ 0x00000000165924c4 10. /build/src/Storages/MergeTree/ReplicatedMergeTreeCleanupThread.cpp:68: DB::ReplicatedMergeTreeCleanupThread::run() @ 0x00000000165913b3 11. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000139630d4 12. /build/src/Core/BackgroundSchedulePool.cpp:308: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001396616a 13. /build/src/Core/BackgroundSchedulePool.cpp:171: void std::__function::__policy_invoker::__call_impl[abi:se190107]::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_1>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_1&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001396690a 14. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc3d92 15. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fcca080 16. ? @ 0x00007fbc6213eac3 17. ? @ 0x00007fbc621d0850 (version 25.3.6.10636.altinitytest (altinity build)) 2025.07.28 11:59:45.356362 [ 3315 ] {} test_1.test_alter_decimal (ReplicatedMergeTreeCleanupThread): void DB::ReplicatedMergeTreeCleanupThread::run(): Code: 999. Coordination::Exception: Coordination error: Connection loss, path /clickhouse/test_1/01761_alter_decimal_zookeeper/blocks. (KEEPER_EXCEPTION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, char const*&&, String const&) @ 0x000000000ba4e10b 4. /build/src/Common/ZooKeeper/KeeperException.h:37: Coordination::Exception::fromPath(Coordination::Error, String const&) @ 0x000000000ba4daab 5. /build/src/Common/ZooKeeper/ZooKeeper.cpp:377: zkutil::ZooKeeper::tryGetChildrenWatch(String const&, std::vector>&, Coordination::Stat*, std::shared_ptr>, Coordination::ListRequestType) @ 0x000000001713de51 6. /build/src/Common/ZooKeeper/ZooKeeper.cpp:347: zkutil::ZooKeeper::tryGetChildren(String const&, std::vector>&, Coordination::Stat*, std::shared_ptr const&, Coordination::ListRequestType) @ 0x000000001713d9b3 7. /build/src/Storages/MergeTree/ReplicatedMergeTreeCleanupThread.cpp:547: DB::ReplicatedMergeTreeCleanupThread::getBlocksSortedByTime(String const&, zkutil::ZooKeeper&, std::vector>&, std::map, std::less, std::allocator>>>&) @ 0x000000001659a909 8. /build/src/Storages/MergeTree/ReplicatedMergeTreeCleanupThread.cpp:477: DB::ReplicatedMergeTreeCleanupThread::clearOldBlocks(String const&, unsigned long, unsigned long, std::map, std::less, std::allocator>>>&) @ 0x00000000165960f8 9. /build/src/Storages/MergeTree/ReplicatedMergeTreeCleanupThread.cpp:194: DB::ReplicatedMergeTreeCleanupThread::iterate() @ 0x00000000165924c4 10. /build/src/Storages/MergeTree/ReplicatedMergeTreeCleanupThread.cpp:68: DB::ReplicatedMergeTreeCleanupThread::run() @ 0x00000000165913b3 11. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000139630d4 12. /build/src/Core/BackgroundSchedulePool.cpp:308: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001396616a 13. /build/src/Core/BackgroundSchedulePool.cpp:171: void std::__function::__policy_invoker::__call_impl[abi:se190107]::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_1>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_1&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001396690a 14. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc3d92 15. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fcca080 16. ? @ 0x00007fbc6213eac3 17. ? @ 0x00007fbc621d0850 (version 25.3.6.10636.altinitytest (altinity build)) 2025.07.28 11:59:45.350950 [ 3656 ] {} test_3.test_03217_merge_replica_1 (3e2f6baa-967c-4f24-9f8c-b72516237951): void DB::StorageReplicatedMergeTree::mutationsUpdatingTask(): Code: 999. Coordination::Exception: Coordination error: Connection loss, path /clickhouse/tables/test_3/test_03217_merge_replica/mutations. (KEEPER_EXCEPTION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, char const*&&, String const&) @ 0x000000000ba4e10b 4. /build/src/Common/ZooKeeper/KeeperException.h:37: Coordination::Exception::fromPath(Coordination::Error, String const&) @ 0x000000000ba4daab 5. /build/src/Common/ZooKeeper/ZooKeeper.cpp:377: zkutil::ZooKeeper::tryGetChildrenWatch(String const&, std::vector>&, Coordination::Stat*, std::shared_ptr>, Coordination::ListRequestType) @ 0x000000001713de51 6. /build/src/Common/ZooKeeper/ZooKeeper.cpp:336: zkutil::ZooKeeper::getChildrenWatch(String const&, Coordination::Stat*, std::shared_ptr>, Coordination::ListRequestType) @ 0x000000001713dd0b 7. /build/src/Storages/MergeTree/ReplicatedMergeTreeQueue.cpp:929: DB::ReplicatedMergeTreeQueue::updateMutations(std::shared_ptr, std::shared_ptr>) @ 0x00000000165c5226 8. /build/src/Storages/StorageReplicatedMergeTree.cpp:3833: DB::StorageReplicatedMergeTree::mutationsUpdatingTask() @ 0x0000000015efbe78 9. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000139630d4 10. /build/src/Core/BackgroundSchedulePool.cpp:308: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001396616a 11. /build/src/Core/BackgroundSchedulePool.cpp:171: void std::__function::__policy_invoker::__call_impl[abi:se190107]::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_1>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_1&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001396690a 12. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc3d92 13. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fcca080 14. ? @ 0x00007fbc6213eac3 15. ? @ 0x00007fbc621d0850 (version 25.3.6.10636.altinitytest (altinity build)) 2025.07.28 11:59:45.358698 [ 3434 ] {} test_15.replicated_summing_merge_tree (ReplicatedMergeTreeCleanupThread): void DB::ReplicatedMergeTreeCleanupThread::run(): Code: 999. Coordination::Exception: Coordination error: Connection loss, path /clickhouse/tables/test_15/test_00083/01/replicated_summing_merge_tree/blocks. (KEEPER_EXCEPTION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, char const*&&, String const&) @ 0x000000000ba4e10b 4. /build/src/Common/ZooKeeper/KeeperException.h:37: Coordination::Exception::fromPath(Coordination::Error, String const&) @ 0x000000000ba4daab 5. /build/src/Common/ZooKeeper/ZooKeeper.cpp:377: zkutil::ZooKeeper::tryGetChildrenWatch(String const&, std::vector>&, Coordination::Stat*, std::shared_ptr>, Coordination::ListRequestType) @ 0x000000001713de51 6. /build/src/Common/ZooKeeper/ZooKeeper.cpp:347: zkutil::ZooKeeper::tryGetChildren(String const&, std::vector>&, Coordination::Stat*, std::shared_ptr const&, Coordination::ListRequestType) @ 0x000000001713d9b3 7. /build/src/Storages/MergeTree/ReplicatedMergeTreeCleanupThread.cpp:547: DB::ReplicatedMergeTreeCleanupThread::getBlocksSortedByTime(String const&, zkutil::ZooKeeper&, std::vector>&, std::map, std::less, std::allocator>>>&) @ 0x000000001659a909 8. /build/src/Storages/MergeTree/ReplicatedMergeTreeCleanupThread.cpp:477: DB::ReplicatedMergeTreeCleanupThread::clearOldBlocks(String const&, unsigned long, unsigned long, std::map, std::less, std::allocator>>>&) @ 0x00000000165960f8 9. /build/src/Storages/MergeTree/ReplicatedMergeTreeCleanupThread.cpp:194: DB::ReplicatedMergeTreeCleanupThread::iterate() @ 0x00000000165924c4 10. /build/src/Storages/MergeTree/ReplicatedMergeTreeCleanupThread.cpp:68: DB::ReplicatedMergeTreeCleanupThread::run() @ 0x00000000165913b3 11. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000139630d4 12. /build/src/Core/BackgroundSchedulePool.cpp:308: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001396616a 13. /build/src/Core/BackgroundSchedulePool.cpp:171: void std::__function::__policy_invoker::__call_impl[abi:se190107]::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_1>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_1&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001396690a 14. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc3d92 15. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fcca080 16. ? @ 0x00007fbc6213eac3 17. ? @ 0x00007fbc621d0850 (version 25.3.6.10636.altinitytest (altinity build)) 2025.07.28 11:59:45.365364 [ 3581 ] {} test_13.rmt1 (043d8a36-28fa-45df-afe1-60a3751a642c): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 999. Coordination::Exception: Coordination error: Connection loss, path /test/01165/test_13/rmt/log. (KEEPER_EXCEPTION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, char const*&&, String const&) @ 0x000000000ba4e10b 4. /build/src/Common/ZooKeeper/KeeperException.h:37: Coordination::Exception::fromPath(Coordination::Error, String const&) @ 0x000000000ba4daab 5. /build/src/Common/ZooKeeper/ZooKeeper.cpp:696: zkutil::ZooKeeper::tryGetWatch(String const&, String&, Coordination::Stat*, std::function, Coordination::Error*) @ 0x0000000017141a56 6. /build/src/Common/ZooKeeper/ZooKeeper.cpp:664: zkutil::ZooKeeper::tryGet(String const&, String&, Coordination::Stat*, std::shared_ptr const&, Coordination::Error*) @ 0x0000000017141736 7. /build/src/Common/ZooKeeper/ZooKeeper.cpp:633: zkutil::ZooKeeper::get(String const&, Coordination::Stat*, std::shared_ptr const&) @ 0x0000000017141598 8. /build/src/Storages/MergeTree/ReplicatedMergeTreeQueue.cpp:645: DB::ReplicatedMergeTreeQueue::pullLogsToQueue(std::shared_ptr, std::function, DB::ReplicatedMergeTreeQueue::PullLogsReason) @ 0x00000000165c10f7 9. /build/src/Storages/StorageReplicatedMergeTree.cpp:3798: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x0000000015efbaeb 10. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000139630d4 11. /build/src/Core/BackgroundSchedulePool.cpp:308: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001396616a 12. /build/src/Core/BackgroundSchedulePool.cpp:171: void std::__function::__policy_invoker::__call_impl[abi:se190107]::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_1>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_1&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001396690a 13. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc3d92 14. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fcca080 15. ? @ 0x00007fbc6213eac3 16. ? @ 0x00007fbc621d0850 (version 25.3.6.10636.altinitytest (altinity build)) 2025.07.28 11:59:45.365762 [ 3505 ] {} test_15.replicated_summing_merge_tree (0b987ac1-9bd0-44c5-914b-5cdc8e023a40): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 999. Coordination::Exception: Coordination error: Connection loss, path /clickhouse/tables/test_15/test_00083/01/replicated_summing_merge_tree/log. (KEEPER_EXCEPTION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, char const*&&, String const&) @ 0x000000000ba4e10b 4. /build/src/Common/ZooKeeper/KeeperException.h:37: Coordination::Exception::fromPath(Coordination::Error, String const&) @ 0x000000000ba4daab 5. /build/src/Common/ZooKeeper/ZooKeeper.cpp:377: zkutil::ZooKeeper::tryGetChildrenWatch(String const&, std::vector>&, Coordination::Stat*, std::shared_ptr>, Coordination::ListRequestType) @ 0x000000001713de51 6. /build/src/Common/ZooKeeper/ZooKeeper.cpp:362: zkutil::ZooKeeper::getChildrenWatch(String const&, Coordination::Stat*, std::function, Coordination::ListRequestType) @ 0x000000001713daed 7. /build/src/Storages/MergeTree/ReplicatedMergeTreeQueue.cpp:647: DB::ReplicatedMergeTreeQueue::pullLogsToQueue(std::shared_ptr, std::function, DB::ReplicatedMergeTreeQueue::PullLogsReason) @ 0x00000000165c12fc 8. /build/src/Storages/StorageReplicatedMergeTree.cpp:3798: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x0000000015efbaeb 9. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000139630d4 10. /build/src/Core/BackgroundSchedulePool.cpp:308: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001396616a 11. /build/src/Core/BackgroundSchedulePool.cpp:171: void std::__function::__policy_invoker::__call_impl[abi:se190107]::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_1>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_1&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001396690a 12. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc3d92 13. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fcca080 14. ? @ 0x00007fbc6213eac3 15. ? @ 0x00007fbc621d0850 (version 25.3.6.10636.altinitytest (altinity build)) 2025.07.28 11:59:45.371174 [ 3787 ] {} test_3.test_03217_merge_replica_2 (e69efe83-5f35-45d0-9489-6b832df60fd9): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 999. Coordination::Exception: Coordination error: Connection loss, path /clickhouse/tables/test_3/test_03217_merge_replica/replicas/r2/log_pointer. (KEEPER_EXCEPTION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, char const*&&, String const&) @ 0x000000000ba4e10b 4. /build/src/Common/ZooKeeper/KeeperException.h:37: Coordination::Exception::fromPath(Coordination::Error, String const&) @ 0x000000000ba4daab 5. /build/src/Common/ZooKeeper/ZooKeeper.cpp:696: zkutil::ZooKeeper::tryGetWatch(String const&, String&, Coordination::Stat*, std::function, Coordination::Error*) @ 0x0000000017141a56 6. /build/src/Common/ZooKeeper/ZooKeeper.cpp:664: zkutil::ZooKeeper::tryGet(String const&, String&, Coordination::Stat*, std::shared_ptr const&, Coordination::Error*) @ 0x0000000017141736 7. /build/src/Common/ZooKeeper/ZooKeeper.cpp:633: zkutil::ZooKeeper::get(String const&, Coordination::Stat*, std::shared_ptr const&) @ 0x0000000017141598 8. /build/src/Storages/MergeTree/ReplicatedMergeTreeQueue.cpp:640: DB::ReplicatedMergeTreeQueue::pullLogsToQueue(std::shared_ptr, std::function, DB::ReplicatedMergeTreeQueue::PullLogsReason) @ 0x00000000165c0e56 9. /build/src/Storages/StorageReplicatedMergeTree.cpp:3798: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x0000000015efbaeb 10. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000139630d4 11. /build/src/Core/BackgroundSchedulePool.cpp:308: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001396616a 12. /build/src/Core/BackgroundSchedulePool.cpp:171: void std::__function::__policy_invoker::__call_impl[abi:se190107]::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_1>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_1&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001396690a 13. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc3d92 14. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fcca080 15. ? @ 0x00007fbc6213eac3 16. ? @ 0x00007fbc621d0850 (version 25.3.6.10636.altinitytest (altinity build)) 2025.07.28 11:59:45.371944 [ 3475 ] {} test_15.replicated_aggregating_merge_tree_with_sampling (37e92af2-c66c-4a58-a583-1c744d6d7379): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 999. Coordination::Exception: Coordination error: Connection loss, path /clickhouse/tables/test_15/test_00083/01/replicated_aggregating_merge_tree_with_sampling/log. (KEEPER_EXCEPTION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, char const*&&, String const&) @ 0x000000000ba4e10b 4. /build/src/Common/ZooKeeper/KeeperException.h:37: Coordination::Exception::fromPath(Coordination::Error, String const&) @ 0x000000000ba4daab 5. /build/src/Common/ZooKeeper/ZooKeeper.cpp:377: zkutil::ZooKeeper::tryGetChildrenWatch(String const&, std::vector>&, Coordination::Stat*, std::shared_ptr>, Coordination::ListRequestType) @ 0x000000001713de51 6. /build/src/Common/ZooKeeper/ZooKeeper.cpp:362: zkutil::ZooKeeper::getChildrenWatch(String const&, Coordination::Stat*, std::function, Coordination::ListRequestType) @ 0x000000001713daed 7. /build/src/Storages/MergeTree/ReplicatedMergeTreeQueue.cpp:647: DB::ReplicatedMergeTreeQueue::pullLogsToQueue(std::shared_ptr, std::function, DB::ReplicatedMergeTreeQueue::PullLogsReason) @ 0x00000000165c12fc 8. /build/src/Storages/StorageReplicatedMergeTree.cpp:3798: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x0000000015efbaeb 9. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000139630d4 10. /build/src/Core/BackgroundSchedulePool.cpp:308: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001396616a 11. /build/src/Core/BackgroundSchedulePool.cpp:171: void std::__function::__policy_invoker::__call_impl[abi:se190107]::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_1>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_1&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001396690a 12. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc3d92 13. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fcca080 14. ? @ 0x00007fbc6213eac3 15. ? @ 0x00007fbc621d0850 (version 25.3.6.10636.altinitytest (altinity build)) 2025.07.28 11:59:45.375595 [ 3517 ] {} test_1.replicated_table_r2 (49032ce5-c582-4bf0-af01-a630a39b2cb8): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 999. Coordination::Exception: Coordination error: Connection loss, path /test/02352/test_1/t_rep/replicas/2/log_pointer. (KEEPER_EXCEPTION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, char const*&&, String const&) @ 0x000000000ba4e10b 4. /build/src/Common/ZooKeeper/KeeperException.h:37: Coordination::Exception::fromPath(Coordination::Error, String const&) @ 0x000000000ba4daab 5. /build/src/Common/ZooKeeper/ZooKeeper.cpp:696: zkutil::ZooKeeper::tryGetWatch(String const&, String&, Coordination::Stat*, std::function, Coordination::Error*) @ 0x0000000017141a56 6. /build/src/Common/ZooKeeper/ZooKeeper.cpp:664: zkutil::ZooKeeper::tryGet(String const&, String&, Coordination::Stat*, std::shared_ptr const&, Coordination::Error*) @ 0x0000000017141736 7. /build/src/Common/ZooKeeper/ZooKeeper.cpp:633: zkutil::ZooKeeper::get(String const&, Coordination::Stat*, std::shared_ptr const&) @ 0x0000000017141598 8. /build/src/Storages/MergeTree/ReplicatedMergeTreeQueue.cpp:640: DB::ReplicatedMergeTreeQueue::pullLogsToQueue(std::shared_ptr, std::function, DB::ReplicatedMergeTreeQueue::PullLogsReason) @ 0x00000000165c0e56 9. /build/src/Storages/StorageReplicatedMergeTree.cpp:3798: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x0000000015efbaeb 10. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000139630d4 11. /build/src/Core/BackgroundSchedulePool.cpp:308: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001396616a 12. /build/src/Core/BackgroundSchedulePool.cpp:171: void std::__function::__policy_invoker::__call_impl[abi:se190107]::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_1>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_1&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001396690a 13. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc3d92 14. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fcca080 15. ? @ 0x00007fbc6213eac3 16. ? @ 0x00007fbc621d0850 (version 25.3.6.10636.altinitytest (altinity build)) 2025.07.28 11:59:45.398942 [ 3660 ] {} test_1.replicated_table_r1 (d9e7bd67-cb9a-45f3-8501-c0895cc2b676): void DB::StorageReplicatedMergeTree::queueUpdatingTask(): Code: 999. Coordination::Exception: Coordination error: Connection loss, path /test/02352/test_1/t_rep/log. (KEEPER_EXCEPTION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, char const*&&, String const&) @ 0x000000000ba4e10b 4. /build/src/Common/ZooKeeper/KeeperException.h:37: Coordination::Exception::fromPath(Coordination::Error, String const&) @ 0x000000000ba4daab 5. /build/src/Common/ZooKeeper/ZooKeeper.cpp:696: zkutil::ZooKeeper::tryGetWatch(String const&, String&, Coordination::Stat*, std::function, Coordination::Error*) @ 0x0000000017141a56 6. /build/src/Common/ZooKeeper/ZooKeeper.cpp:664: zkutil::ZooKeeper::tryGet(String const&, String&, Coordination::Stat*, std::shared_ptr const&, Coordination::Error*) @ 0x0000000017141736 7. /build/src/Common/ZooKeeper/ZooKeeper.cpp:633: zkutil::ZooKeeper::get(String const&, Coordination::Stat*, std::shared_ptr const&) @ 0x0000000017141598 8. /build/src/Storages/MergeTree/ReplicatedMergeTreeQueue.cpp:645: DB::ReplicatedMergeTreeQueue::pullLogsToQueue(std::shared_ptr, std::function, DB::ReplicatedMergeTreeQueue::PullLogsReason) @ 0x00000000165c10f7 9. /build/src/Storages/StorageReplicatedMergeTree.cpp:3798: DB::StorageReplicatedMergeTree::queueUpdatingTask() @ 0x0000000015efbaeb 10. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000139630d4 11. /build/src/Core/BackgroundSchedulePool.cpp:308: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001396616a 12. /build/src/Core/BackgroundSchedulePool.cpp:171: void std::__function::__policy_invoker::__call_impl[abi:se190107]::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_1>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_1&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001396690a 13. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc3d92 14. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fcca080 15. ? @ 0x00007fbc6213eac3 16. ? @ 0x00007fbc621d0850 (version 25.3.6.10636.altinitytest (altinity build)) 2025.07.28 11:59:45.400663 [ 3310 ] {} test_15.replicated_aggregating_merge_tree_with_sampling (ReplicatedMergeTreeCleanupThread): void DB::ReplicatedMergeTreeCleanupThread::run(): Code: 999. Coordination::Exception: Coordination error: Connection loss. (KEEPER_EXCEPTION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type>, char const*&&) @ 0x000000000c7f5eab 4. /build/src/Common/ZooKeeper/KeeperException.h:37: Coordination::Exception::Exception(Coordination::Error, FormatStringHelperImpl::type>, char const*&&) @ 0x0000000017136dce 5. /build/src/Common/ZooKeeper/KeeperException.cpp:35: Coordination::Exception::Exception(Coordination::Error) @ 0x0000000017136d3d 6. /build/src/Common/ZooKeeper/ZooKeeper.cpp:823: zkutil::ZooKeeper::tryMulti(std::vector, std::allocator>> const&, std::vector, std::allocator>>&, bool) @ 0x0000000017142d72 7. /build/src/Common/ZooKeeper/ZooKeeper.h:665: zkutil::MultiReadResponses zkutil::ZooKeeper::multiRead>(std::__wrap_iter, std::__wrap_iter, std::function (String const&)>, std::function (String const&)>) @ 0x0000000015e144fc 8. /build/src/Common/ZooKeeper/ZooKeeper.h:288: zkutil::MultiReadResponses zkutil::ZooKeeper::exists>(std::__wrap_iter, std::__wrap_iter) @ 0x0000000015e14235 9. /build/src/Common/ZooKeeper/ZooKeeper.h:294: DB::ReplicatedMergeTreeCleanupThread::getBlocksSortedByTime(String const&, zkutil::ZooKeeper&, std::vector>&, std::map, std::less, std::allocator>>>&) @ 0x000000001659b483 10. /build/src/Storages/MergeTree/ReplicatedMergeTreeCleanupThread.cpp:477: DB::ReplicatedMergeTreeCleanupThread::clearOldBlocks(String const&, unsigned long, unsigned long, std::map, std::less, std::allocator>>>&) @ 0x00000000165960f8 11. /build/src/Storages/MergeTree/ReplicatedMergeTreeCleanupThread.cpp:194: DB::ReplicatedMergeTreeCleanupThread::iterate() @ 0x00000000165924c4 12. /build/src/Storages/MergeTree/ReplicatedMergeTreeCleanupThread.cpp:68: DB::ReplicatedMergeTreeCleanupThread::run() @ 0x00000000165913b3 13. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000139630d4 14. /build/src/Core/BackgroundSchedulePool.cpp:308: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001396616a 15. /build/src/Core/BackgroundSchedulePool.cpp:171: void std::__function::__policy_invoker::__call_impl[abi:se190107]::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_1>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_1&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001396690a 16. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc3d92 17. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fcca080 18. ? @ 0x00007fbc6213eac3 19. ? @ 0x00007fbc621d0850 (version 25.3.6.10636.altinitytest (altinity build)) 2025.07.28 11:59:45.408425 [ 7415 ] {} DDLWorker(test_9_db): Error on initialization of test_9_db: Code: 999. Coordination::Exception: Coordination error: Connection loss, path /test/clickhouse/db/test_9_db/replicas/s1|r1/active. (KEEPER_EXCEPTION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, char const*&&, String const&) @ 0x000000000ba4e10b 4. /build/src/Common/ZooKeeper/KeeperException.h:37: Coordination::Exception::fromPath(Coordination::Error, String const&) @ 0x000000000ba4daab 5. /build/src/Common/ZooKeeper/ZooKeeper.cpp:696: zkutil::ZooKeeper::tryGetWatch(String const&, String&, Coordination::Stat*, std::function, Coordination::Error*) @ 0x0000000017141a56 6. /build/src/Common/ZooKeeper/ZooKeeper.cpp:664: zkutil::ZooKeeper::tryGet(String const&, String&, Coordination::Stat*, std::shared_ptr const&, Coordination::Error*) @ 0x0000000017141736 7. /build/src/Common/ZooKeeper/ZooKeeper.cpp:1079: zkutil::ZooKeeper::deleteEphemeralNodeIfContentMatches(String const&, String const&) @ 0x00000000171461e7 8. /build/src/Databases/DatabaseReplicatedWorker.cpp:140: DB::DatabaseReplicatedDDLWorker::initializeReplication() @ 0x0000000013dbd88d 9. /build/src/Databases/DatabaseReplicatedWorker.cpp:101: DB::DatabaseReplicatedDDLWorker::initializeMainThread() @ 0x0000000013dbcb49 10. /build/src/Interpreters/DDLWorker.cpp:1189: DB::DDLWorker::runMainThread() @ 0x00000000144cf431 11. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl(void (DB::DDLWorker::*&&)(), DB::DDLWorker*&&)::'lambda'()::operator()() @ 0x00000000144ead03 12. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc3d92 13. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fcca080 14. ? @ 0x00007fbc6213eac3 15. ? @ 0x00007fbc621d0850 Job's origin stack trace: 0. /build/src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000000fc33b84 1. /build/src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000000fcc2ea7 2. /build/src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fcc535c 3. /build/src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000000fcc584d 4. /build/src/Common/ThreadPool.h:279: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl(void (DB::DDLWorker::*&&)(), DB::DDLWorker*&&) @ 0x00000000144eab91 5. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: DB::DDLWorker::startup() @ 0x00000000144cefb2 6. /build/src/Databases/DatabaseReplicated.cpp:772: void std::__function::__policy_invoker const&)>::__call_impl[abi:se190107], std::hash>, std::equal_to>, std::allocator>>, DB::LoadingStrictnessLevel)::$_0, void (DB::AsyncLoader&, std::shared_ptr const&)>>(std::__function::__policy_storage const*, DB::AsyncLoader&, std::shared_ptr const&) @ 0x0000000013db4204 7. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fe5fbdd 8. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc6653 9. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000000fccc4c3 10. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc3d92 11. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fcca080 12. ? @ 0x00007fbc6213eac3 13. ? @ 0x00007fbc621d0850 Job's origin stack trace: 0. /build/src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000000fc33b84 1. /build/src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000000fcc2ea7 2. /build/src/Common/ThreadPool.cpp:401: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fcc7f1c 3. /build/src/Common/ThreadPool.cpp:494: ThreadPoolImpl>::scheduleOrThrowOnError(std::function, Priority) @ 0x000000000fcc7a0e 4. /build/src/Common/AsyncLoader.cpp:882: DB::AsyncLoader::spawn(DB::AsyncLoader::Pool&, std::unique_lock&) @ 0x000000000fe5d9c2 5. /build/src/Common/AsyncLoader.cpp:718: DB::AsyncLoader::enqueue(DB::AsyncLoader::Info&, std::shared_ptr const&, std::unique_lock&) @ 0x000000000fe5b0e6 6. /build/src/Common/AsyncLoader.cpp:375: DB::AsyncLoader::schedule(std::unordered_set, std::hash>, std::equal_to>, std::allocator>> const&) @ 0x000000000fe59036 7. /build/src/Common/AsyncLoader.cpp:312: DB::AsyncLoader::schedule(std::vector, std::allocator>> const&) @ 0x000000000fe59c85 8. /build/src/Common/AsyncLoader.h:541: DB::waitLoad(unsigned long, std::vector, std::allocator>> const&, bool) @ 0x000000000fe45f34 9. /build/src/Interpreters/InterpreterCreateQuery.cpp:388: DB::InterpreterCreateQuery::createDatabase(DB::ASTCreateQuery&) @ 0x00000000148e8f82 10. /build/src/Interpreters/InterpreterCreateQuery.cpp:2351: DB::InterpreterCreateQuery::execute() @ 0x0000000014905a3a 11. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88dc9 12. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 13. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 14. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 15. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 16. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 17. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 18. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 19. ? @ 0x00007fbc6213eac3 20. ? @ 0x00007fbc621d0850 (version 25.3.6.10636.altinitytest (altinity build)) 2025.07.28 11:59:45.409018 [ 4747 ] {} DDLWorker(test_11): Error on initialization of test_11: Code: 999. Coordination::Exception: Coordination error: Connection loss, path /test/db/test_11/replicas/s1|r1/active. (KEEPER_EXCEPTION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, char const*&&, String const&) @ 0x000000000ba4e10b 4. /build/src/Common/ZooKeeper/KeeperException.h:37: Coordination::Exception::fromPath(Coordination::Error, String const&) @ 0x000000000ba4daab 5. /build/src/Common/ZooKeeper/ZooKeeper.cpp:696: zkutil::ZooKeeper::tryGetWatch(String const&, String&, Coordination::Stat*, std::function, Coordination::Error*) @ 0x0000000017141a56 6. /build/src/Common/ZooKeeper/ZooKeeper.cpp:664: zkutil::ZooKeeper::tryGet(String const&, String&, Coordination::Stat*, std::shared_ptr const&, Coordination::Error*) @ 0x0000000017141736 7. /build/src/Common/ZooKeeper/ZooKeeper.cpp:1079: zkutil::ZooKeeper::deleteEphemeralNodeIfContentMatches(String const&, String const&) @ 0x00000000171461e7 8. /build/src/Databases/DatabaseReplicatedWorker.cpp:140: DB::DatabaseReplicatedDDLWorker::initializeReplication() @ 0x0000000013dbd88d 9. /build/src/Databases/DatabaseReplicatedWorker.cpp:101: DB::DatabaseReplicatedDDLWorker::initializeMainThread() @ 0x0000000013dbcb49 10. /build/src/Interpreters/DDLWorker.cpp:1189: DB::DDLWorker::runMainThread() @ 0x00000000144cf431 11. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl(void (DB::DDLWorker::*&&)(), DB::DDLWorker*&&)::'lambda'()::operator()() @ 0x00000000144ead03 12. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc3d92 13. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fcca080 14. ? @ 0x00007fbc6213eac3 15. ? @ 0x00007fbc621d0850 Job's origin stack trace: 0. /build/src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000000fc33b84 1. /build/src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000000fcc2ea7 2. /build/src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fcc535c 3. /build/src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000000fcc584d 4. /build/src/Common/ThreadPool.h:279: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl(void (DB::DDLWorker::*&&)(), DB::DDLWorker*&&) @ 0x00000000144eab91 5. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: DB::DDLWorker::startup() @ 0x00000000144cefb2 6. /build/src/Databases/DatabaseReplicated.cpp:772: void std::__function::__policy_invoker const&)>::__call_impl[abi:se190107], std::hash>, std::equal_to>, std::allocator>>, DB::LoadingStrictnessLevel)::$_0, void (DB::AsyncLoader&, std::shared_ptr const&)>>(std::__function::__policy_storage const*, DB::AsyncLoader&, std::shared_ptr const&) @ 0x0000000013db4204 7. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fe5fbdd 8. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc6653 9. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000000fccc4c3 10. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc3d92 11. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fcca080 12. ? @ 0x00007fbc6213eac3 13. ? @ 0x00007fbc621d0850 Job's origin stack trace: 0. /build/src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000000fc33b84 1. /build/src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000000fcc2ea7 2. /build/src/Common/ThreadPool.cpp:401: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fcc7f1c 3. /build/src/Common/ThreadPool.cpp:494: ThreadPoolImpl>::scheduleOrThrowOnError(std::function, Priority) @ 0x000000000fcc7a0e 4. /build/src/Common/AsyncLoader.cpp:882: DB::AsyncLoader::spawn(DB::AsyncLoader::Pool&, std::unique_lock&) @ 0x000000000fe5d9c2 5. /build/src/Common/AsyncLoader.cpp:718: DB::AsyncLoader::enqueue(DB::AsyncLoader::Info&, std::shared_ptr const&, std::unique_lock&) @ 0x000000000fe5b0e6 6. /build/src/Common/AsyncLoader.cpp:375: DB::AsyncLoader::schedule(std::unordered_set, std::hash>, std::equal_to>, std::allocator>> const&) @ 0x000000000fe59036 7. /build/src/Common/AsyncLoader.cpp:312: DB::AsyncLoader::schedule(std::vector, std::allocator>> const&) @ 0x000000000fe59c85 8. /build/src/Common/AsyncLoader.h:541: DB::waitLoad(unsigned long, std::vector, std::allocator>> const&, bool) @ 0x000000000fe45f34 9. /build/src/Interpreters/InterpreterCreateQuery.cpp:388: DB::InterpreterCreateQuery::createDatabase(DB::ASTCreateQuery&) @ 0x00000000148e8f82 10. /build/src/Interpreters/InterpreterCreateQuery.cpp:2351: DB::InterpreterCreateQuery::execute() @ 0x0000000014905a3a 11. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88dc9 12. /build/src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x0000000014c8ca7b 13. /build/src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000001686da12 14. /build/src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x0000000016870807 15. /build/src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x0000000016907e99 16. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 17. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 18. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 19. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 20. ? @ 0x00007fbc6213eac3 21. ? @ 0x00007fbc621d0850 (version 25.3.6.10636.altinitytest (altinity build)) 2025.07.28 11:59:45.409232 [ 4220 ] {} DDLWorker(test_5): Error on initialization of test_5: Code: 999. Coordination::Exception: Coordination error: Connection loss, path /test/db/test_5/replicas/s1|r1/active. (KEEPER_EXCEPTION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, char const*&&, String const&) @ 0x000000000ba4e10b 4. /build/src/Common/ZooKeeper/KeeperException.h:37: Coordination::Exception::fromPath(Coordination::Error, String const&) @ 0x000000000ba4daab 5. /build/src/Common/ZooKeeper/ZooKeeper.cpp:696: zkutil::ZooKeeper::tryGetWatch(String const&, String&, Coordination::Stat*, std::function, Coordination::Error*) @ 0x0000000017141a56 6. /build/src/Common/ZooKeeper/ZooKeeper.cpp:664: zkutil::ZooKeeper::tryGet(String const&, String&, Coordination::Stat*, std::shared_ptr const&, Coordination::Error*) @ 0x0000000017141736 7. /build/src/Common/ZooKeeper/ZooKeeper.cpp:1079: zkutil::ZooKeeper::deleteEphemeralNodeIfContentMatches(String const&, String const&) @ 0x00000000171461e7 8. /build/src/Databases/DatabaseReplicatedWorker.cpp:140: DB::DatabaseReplicatedDDLWorker::initializeReplication() @ 0x0000000013dbd88d 9. /build/src/Databases/DatabaseReplicatedWorker.cpp:101: DB::DatabaseReplicatedDDLWorker::initializeMainThread() @ 0x0000000013dbcb49 10. /build/src/Interpreters/DDLWorker.cpp:1189: DB::DDLWorker::runMainThread() @ 0x00000000144cf431 11. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl(void (DB::DDLWorker::*&&)(), DB::DDLWorker*&&)::'lambda'()::operator()() @ 0x00000000144ead03 12. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc3d92 13. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fcca080 14. ? @ 0x00007fbc6213eac3 15. ? @ 0x00007fbc621d0850 Job's origin stack trace: 0. /build/src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000000fc33b84 1. /build/src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000000fcc2ea7 2. /build/src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fcc535c 3. /build/src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000000fcc584d 4. /build/src/Common/ThreadPool.h:279: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl(void (DB::DDLWorker::*&&)(), DB::DDLWorker*&&) @ 0x00000000144eab91 5. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: DB::DDLWorker::startup() @ 0x00000000144cefb2 6. /build/src/Databases/DatabaseReplicated.cpp:772: void std::__function::__policy_invoker const&)>::__call_impl[abi:se190107], std::hash>, std::equal_to>, std::allocator>>, DB::LoadingStrictnessLevel)::$_0, void (DB::AsyncLoader&, std::shared_ptr const&)>>(std::__function::__policy_storage const*, DB::AsyncLoader&, std::shared_ptr const&) @ 0x0000000013db4204 7. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fe5fbdd 8. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc6653 9. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000000fccc4c3 10. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc3d92 11. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fcca080 12. ? @ 0x00007fbc6213eac3 13. ? @ 0x00007fbc621d0850 Job's origin stack trace: 0. /build/src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000000fc33b84 1. /build/src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000000fcc2ea7 2. /build/src/Common/ThreadPool.cpp:401: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fcc7f1c 3. /build/src/Common/ThreadPool.cpp:494: ThreadPoolImpl>::scheduleOrThrowOnError(std::function, Priority) @ 0x000000000fcc7a0e 4. /build/src/Common/AsyncLoader.cpp:882: DB::AsyncLoader::spawn(DB::AsyncLoader::Pool&, std::unique_lock&) @ 0x000000000fe5d9c2 5. /build/src/Common/AsyncLoader.cpp:718: DB::AsyncLoader::enqueue(DB::AsyncLoader::Info&, std::shared_ptr const&, std::unique_lock&) @ 0x000000000fe5b0e6 6. /build/src/Common/AsyncLoader.cpp:375: DB::AsyncLoader::schedule(std::unordered_set, std::hash>, std::equal_to>, std::allocator>> const&) @ 0x000000000fe59036 7. /build/src/Common/AsyncLoader.cpp:312: DB::AsyncLoader::schedule(std::vector, std::allocator>> const&) @ 0x000000000fe59c85 8. /build/src/Common/AsyncLoader.h:541: DB::waitLoad(unsigned long, std::vector, std::allocator>> const&, bool) @ 0x000000000fe45f34 9. /build/src/Interpreters/InterpreterCreateQuery.cpp:388: DB::InterpreterCreateQuery::createDatabase(DB::ASTCreateQuery&) @ 0x00000000148e8f82 10. /build/src/Interpreters/InterpreterCreateQuery.cpp:2351: DB::InterpreterCreateQuery::execute() @ 0x0000000014905a3a 11. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88dc9 12. /build/src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x0000000014c8ca7b 13. /build/src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000001686da12 14. /build/src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x0000000016870807 15. /build/src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x0000000016907e99 16. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 17. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 18. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 19. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 20. ? @ 0x00007fbc6213eac3 21. ? @ 0x00007fbc621d0850 (version 25.3.6.10636.altinitytest (altinity build)) 2025.07.28 11:59:45.409270 [ 3769 ] {} test_1.t_json_3 (ReplicatedMergeTreeCleanupThread): void DB::ReplicatedMergeTreeCleanupThread::run(): Code: 999. Coordination::Exception: Coordination error: Connection loss, path /clickhouse/tables/test_1/test_01825_3/t_json_3/async_blocks. (KEEPER_EXCEPTION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, char const*&&, String const&) @ 0x000000000ba4e10b 4. /build/src/Common/ZooKeeper/KeeperException.h:37: Coordination::Exception::fromPath(Coordination::Error, String const&) @ 0x000000000ba4daab 5. /build/src/Common/ZooKeeper/ZooKeeper.cpp:377: zkutil::ZooKeeper::tryGetChildrenWatch(String const&, std::vector>&, Coordination::Stat*, std::shared_ptr>, Coordination::ListRequestType) @ 0x000000001713de51 6. /build/src/Common/ZooKeeper/ZooKeeper.cpp:347: zkutil::ZooKeeper::tryGetChildren(String const&, std::vector>&, Coordination::Stat*, std::shared_ptr const&, Coordination::ListRequestType) @ 0x000000001713d9b3 7. /build/src/Storages/MergeTree/ReplicatedMergeTreeCleanupThread.cpp:547: DB::ReplicatedMergeTreeCleanupThread::getBlocksSortedByTime(String const&, zkutil::ZooKeeper&, std::vector>&, std::map, std::less, std::allocator>>>&) @ 0x000000001659a909 8. /build/src/Storages/MergeTree/ReplicatedMergeTreeCleanupThread.cpp:477: DB::ReplicatedMergeTreeCleanupThread::clearOldBlocks(String const&, unsigned long, unsigned long, std::map, std::less, std::allocator>>>&) @ 0x00000000165960f8 9. /build/src/Storages/MergeTree/ReplicatedMergeTreeCleanupThread.cpp:197: DB::ReplicatedMergeTreeCleanupThread::iterate() @ 0x000000001659253e 10. /build/src/Storages/MergeTree/ReplicatedMergeTreeCleanupThread.cpp:68: DB::ReplicatedMergeTreeCleanupThread::run() @ 0x00000000165913b3 11. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000139630d4 12. /build/src/Core/BackgroundSchedulePool.cpp:308: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001396616a 13. /build/src/Core/BackgroundSchedulePool.cpp:171: void std::__function::__policy_invoker::__call_impl[abi:se190107]::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_1>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_1&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001396690a 14. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc3d92 15. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fcca080 16. ? @ 0x00007fbc6213eac3 17. ? @ 0x00007fbc621d0850 (version 25.3.6.10636.altinitytest (altinity build)) 2025.07.28 11:59:45.410918 [ 3372 ] {} test_1.replicated_table_r1 (ReplicatedMergeTreeCleanupThread): void DB::ReplicatedMergeTreeCleanupThread::run(): Code: 999. Coordination::Exception: Coordination error: Connection loss, path /test/02352/test_1/t_rep/log. (KEEPER_EXCEPTION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, char const*&&, String const&) @ 0x000000000ba4e10b 4. /build/src/Common/ZooKeeper/KeeperException.h:37: Coordination::Exception::fromPath(Coordination::Error, String const&) @ 0x000000000ba4daab 5. /build/src/Common/ZooKeeper/ZooKeeper.cpp:598: zkutil::ZooKeeper::existsWatch(String const&, Coordination::Stat*, std::function) @ 0x0000000017140c7a 6. /build/src/Common/ZooKeeper/ZooKeeper.cpp:579: zkutil::ZooKeeper::exists(String const&, Coordination::Stat*, std::shared_ptr const&) @ 0x000000001713e7a8 7. /build/src/Storages/MergeTree/ReplicatedMergeTreeCleanupThread.cpp:235: DB::ReplicatedMergeTreeCleanupThread::clearOldLogs() @ 0x00000000165930c3 8. /build/src/Storages/MergeTree/ReplicatedMergeTreeCleanupThread.cpp:193: DB::ReplicatedMergeTreeCleanupThread::iterate() @ 0x0000000016592463 9. /build/src/Storages/MergeTree/ReplicatedMergeTreeCleanupThread.cpp:68: DB::ReplicatedMergeTreeCleanupThread::run() @ 0x00000000165913b3 10. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000139630d4 11. /build/src/Core/BackgroundSchedulePool.cpp:308: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001396616a 12. /build/src/Core/BackgroundSchedulePool.cpp:171: void std::__function::__policy_invoker::__call_impl[abi:se190107]::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_1>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_1&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001396690a 13. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc3d92 14. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fcca080 15. ? @ 0x00007fbc6213eac3 16. ? @ 0x00007fbc621d0850 (version 25.3.6.10636.altinitytest (altinity build)) 2025.07.28 11:59:45.411135 [ 3735 ] {} test_13.rmt2 (ReplicatedMergeTreeRestartingThread): Couldn't start replication (table will be in readonly mode): Coordination error: Connection loss, path /test/01165/test_13/rmt/quorum/status. Code: 999. Coordination::Exception: Coordination error: Connection loss, path /test/01165/test_13/rmt/quorum/status. (KEEPER_EXCEPTION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, char const*&&, String const&) @ 0x000000000ba4e10b 4. /build/src/Common/ZooKeeper/KeeperException.h:37: Coordination::Exception::fromPath(Coordination::Error, String const&) @ 0x000000000ba4daab 5. /build/src/Common/ZooKeeper/ZooKeeper.cpp:696: zkutil::ZooKeeper::tryGetWatch(String const&, String&, Coordination::Stat*, std::function, Coordination::Error*) @ 0x0000000017141a56 6. /build/src/Common/ZooKeeper/ZooKeeper.cpp:664: zkutil::ZooKeeper::tryGet(String const&, String&, Coordination::Stat*, std::shared_ptr const&, Coordination::Error*) @ 0x0000000017141736 7. /build/src/Storages/MergeTree/ReplicatedMergeTreeRestartingThread.cpp:296: DB::ReplicatedMergeTreeRestartingThread::updateQuorumIfWeHavePart() @ 0x00000000165eea2a 8. /build/src/Storages/MergeTree/ReplicatedMergeTreeRestartingThread.cpp:230: DB::ReplicatedMergeTreeRestartingThread::tryStartup() @ 0x00000000165e9c87 9. /build/src/Storages/MergeTree/ReplicatedMergeTreeRestartingThread.cpp:160: DB::ReplicatedMergeTreeRestartingThread::runImpl() @ 0x00000000165e8af8 10. /build/src/Storages/MergeTree/ReplicatedMergeTreeRestartingThread.cpp:86: DB::ReplicatedMergeTreeRestartingThread::run() @ 0x00000000165e803e 11. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000139630d4 12. /build/src/Core/BackgroundSchedulePool.cpp:308: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001396616a 13. /build/src/Core/BackgroundSchedulePool.cpp:171: void std::__function::__policy_invoker::__call_impl[abi:se190107]::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_1>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_1&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001396690a 14. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc3d92 15. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fcca080 16. ? @ 0x00007fbc6213eac3 17. ? @ 0x00007fbc621d0850 (version 25.3.6.10636.altinitytest (altinity build)) 2025.07.28 11:59:45.411285 [ 3361 ] {} test_1.replicated_table_r2 (ReplicatedMergeTreeCleanupThread): void DB::ReplicatedMergeTreeCleanupThread::run(): Code: 999. Coordination::Exception: Coordination error: Connection loss, path /test/02352/test_1/t_rep/log. (KEEPER_EXCEPTION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, char const*&&, String const&) @ 0x000000000ba4e10b 4. /build/src/Common/ZooKeeper/KeeperException.h:37: Coordination::Exception::fromPath(Coordination::Error, String const&) @ 0x000000000ba4daab 5. /build/src/Common/ZooKeeper/ZooKeeper.cpp:598: zkutil::ZooKeeper::existsWatch(String const&, Coordination::Stat*, std::function) @ 0x0000000017140c7a 6. /build/src/Common/ZooKeeper/ZooKeeper.cpp:579: zkutil::ZooKeeper::exists(String const&, Coordination::Stat*, std::shared_ptr const&) @ 0x000000001713e7a8 7. /build/src/Storages/MergeTree/ReplicatedMergeTreeCleanupThread.cpp:235: DB::ReplicatedMergeTreeCleanupThread::clearOldLogs() @ 0x00000000165930c3 8. /build/src/Storages/MergeTree/ReplicatedMergeTreeCleanupThread.cpp:193: DB::ReplicatedMergeTreeCleanupThread::iterate() @ 0x0000000016592463 9. /build/src/Storages/MergeTree/ReplicatedMergeTreeCleanupThread.cpp:68: DB::ReplicatedMergeTreeCleanupThread::run() @ 0x00000000165913b3 10. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000139630d4 11. /build/src/Core/BackgroundSchedulePool.cpp:308: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001396616a 12. /build/src/Core/BackgroundSchedulePool.cpp:171: void std::__function::__policy_invoker::__call_impl[abi:se190107]::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_1>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_1&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001396690a 13. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc3d92 14. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fcca080 15. ? @ 0x00007fbc6213eac3 16. ? @ 0x00007fbc621d0850 (version 25.3.6.10636.altinitytest (altinity build)) 2025.07.28 11:59:45.412842 [ 3722 ] {} test_13.rmt2 (ReplicatedMergeTreeRestartingThread): Table was in readonly mode. Will try to activate it. 2025.07.28 11:59:45.414107 [ 3418 ] {} test_13.rmt1 (ReplicatedMergeTreeCleanupThread): void DB::ReplicatedMergeTreeCleanupThread::run(): Code: 999. Coordination::Exception: Coordination error: Connection loss, path /test/01165/test_13/rmt/log. (KEEPER_EXCEPTION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, char const*&&, String const&) @ 0x000000000ba4e10b 4. /build/src/Common/ZooKeeper/KeeperException.h:37: Coordination::Exception::fromPath(Coordination::Error, String const&) @ 0x000000000ba4daab 5. /build/src/Common/ZooKeeper/ZooKeeper.cpp:598: zkutil::ZooKeeper::existsWatch(String const&, Coordination::Stat*, std::function) @ 0x0000000017140c7a 6. /build/src/Common/ZooKeeper/ZooKeeper.cpp:579: zkutil::ZooKeeper::exists(String const&, Coordination::Stat*, std::shared_ptr const&) @ 0x000000001713e7a8 7. /build/src/Storages/MergeTree/ReplicatedMergeTreeCleanupThread.cpp:235: DB::ReplicatedMergeTreeCleanupThread::clearOldLogs() @ 0x00000000165930c3 8. /build/src/Storages/MergeTree/ReplicatedMergeTreeCleanupThread.cpp:193: DB::ReplicatedMergeTreeCleanupThread::iterate() @ 0x0000000016592463 9. /build/src/Storages/MergeTree/ReplicatedMergeTreeCleanupThread.cpp:68: DB::ReplicatedMergeTreeCleanupThread::run() @ 0x00000000165913b3 10. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000139630d4 11. /build/src/Core/BackgroundSchedulePool.cpp:308: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001396616a 12. /build/src/Core/BackgroundSchedulePool.cpp:171: void std::__function::__policy_invoker::__call_impl[abi:se190107]::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_1>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_1&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001396690a 13. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc3d92 14. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fcca080 15. ? @ 0x00007fbc6213eac3 16. ? @ 0x00007fbc621d0850 (version 25.3.6.10636.altinitytest (altinity build)) 2025.07.28 11:59:45.417261 [ 3693 ] {} test_3.test_03217_merge_replica_1 (ReplicatedMergeTreeCleanupThread): void DB::ReplicatedMergeTreeCleanupThread::run(): Code: 999. Coordination::Exception: Coordination error: Connection loss, path /clickhouse/tables/test_3/test_03217_merge_replica/log. (KEEPER_EXCEPTION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, char const*&&, String const&) @ 0x000000000ba4e10b 4. /build/src/Common/ZooKeeper/KeeperException.h:37: Coordination::Exception::fromPath(Coordination::Error, String const&) @ 0x000000000ba4daab 5. /build/src/Common/ZooKeeper/ZooKeeper.cpp:598: zkutil::ZooKeeper::existsWatch(String const&, Coordination::Stat*, std::function) @ 0x0000000017140c7a 6. /build/src/Common/ZooKeeper/ZooKeeper.cpp:579: zkutil::ZooKeeper::exists(String const&, Coordination::Stat*, std::shared_ptr const&) @ 0x000000001713e7a8 7. /build/src/Storages/MergeTree/ReplicatedMergeTreeCleanupThread.cpp:235: DB::ReplicatedMergeTreeCleanupThread::clearOldLogs() @ 0x00000000165930c3 8. /build/src/Storages/MergeTree/ReplicatedMergeTreeCleanupThread.cpp:193: DB::ReplicatedMergeTreeCleanupThread::iterate() @ 0x0000000016592463 9. /build/src/Storages/MergeTree/ReplicatedMergeTreeCleanupThread.cpp:68: DB::ReplicatedMergeTreeCleanupThread::run() @ 0x00000000165913b3 10. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000139630d4 11. /build/src/Core/BackgroundSchedulePool.cpp:308: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001396616a 12. /build/src/Core/BackgroundSchedulePool.cpp:171: void std::__function::__policy_invoker::__call_impl[abi:se190107]::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_1>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_1&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001396690a 13. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc3d92 14. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fcca080 15. ? @ 0x00007fbc6213eac3 16. ? @ 0x00007fbc621d0850 (version 25.3.6.10636.altinitytest (altinity build)) 2025.07.28 11:59:45.418580 [ 3536 ] {} test_3.test_03217_merge_replica_2 (ReplicatedMergeTreeCleanupThread): void DB::ReplicatedMergeTreeCleanupThread::run(): Code: 999. Coordination::Exception: Coordination error: Connection loss, path /clickhouse/tables/test_3/test_03217_merge_replica/log. (KEEPER_EXCEPTION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, char const*&&, String const&) @ 0x000000000ba4e10b 4. /build/src/Common/ZooKeeper/KeeperException.h:37: Coordination::Exception::fromPath(Coordination::Error, String const&) @ 0x000000000ba4daab 5. /build/src/Common/ZooKeeper/ZooKeeper.cpp:598: zkutil::ZooKeeper::existsWatch(String const&, Coordination::Stat*, std::function) @ 0x0000000017140c7a 6. /build/src/Common/ZooKeeper/ZooKeeper.cpp:579: zkutil::ZooKeeper::exists(String const&, Coordination::Stat*, std::shared_ptr const&) @ 0x000000001713e7a8 7. /build/src/Storages/MergeTree/ReplicatedMergeTreeCleanupThread.cpp:235: DB::ReplicatedMergeTreeCleanupThread::clearOldLogs() @ 0x00000000165930c3 8. /build/src/Storages/MergeTree/ReplicatedMergeTreeCleanupThread.cpp:193: DB::ReplicatedMergeTreeCleanupThread::iterate() @ 0x0000000016592463 9. /build/src/Storages/MergeTree/ReplicatedMergeTreeCleanupThread.cpp:68: DB::ReplicatedMergeTreeCleanupThread::run() @ 0x00000000165913b3 10. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000139630d4 11. /build/src/Core/BackgroundSchedulePool.cpp:308: DB::BackgroundSchedulePool::threadFunction() @ 0x000000001396616a 12. /build/src/Core/BackgroundSchedulePool.cpp:171: void std::__function::__policy_invoker::__call_impl[abi:se190107]::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_1>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_1&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000001396690a 13. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc3d92 14. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fcca080 15. ? @ 0x00007fbc6213eac3 16. ? @ 0x00007fbc621d0850 (version 25.3.6.10636.altinitytest (altinity build)) 2025.07.28 11:59:46.507225 [ 3968 ] {} test_13.rmt2 (7f9b740d-015c-470e-8cc6-8ba33be0dc63): auto DB::StorageReplicatedMergeTree::processQueueEntry(ReplicatedMergeTreeQueue::SelectedEntryPtr)::(anonymous class)::operator()(LogEntryPtr &) const: Code: 86. DB::HTTPException: Received error from remote server http://146b4357c08d:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Ftest%2F01165%2Ftest_13%2Frmt%2Freplicas%2F1&part=20250728_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.6.10636.altinitytest (altinity build)) '. (RECEIVED_ERROR_FROM_REMOTE_IO_SERVER), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.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 const&, int&&, String const&, unsigned long&&, String const&) @ 0x000000000feda8d9 4. /build/src/IO/HTTPCommon.cpp:104: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x000000000feda6e2 5. /build/src/IO/HTTPCommon.cpp:93: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x000000000feda537 6. /build/src/IO/ReadWriteBufferFromHTTP.cpp:277: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x000000001184a4c4 7. /build/src/IO/ReadWriteBufferFromHTTP.cpp:285: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x000000001184a615 8. /build/src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x000000001184ae59 9. /build/src/IO/ReadWriteBufferFromHTTP.cpp:472: void std::__function::__policy_invoker::__call_impl[abi:se190107]>(std::__function::__policy_storage const*) @ 0x000000001184cedd 10. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001184858b 11. /build/src/IO/ReadWriteBufferFromHTTP.cpp:465: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x000000001184bf0b 12. /build/src/IO/ReadBuffer.h:60: DB::ReadBuffer::next() @ 0x000000000a148c7b 13. /build/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) @ 0x0000000011849fb2 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]>&)>&, 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&) @ 0x0000000011841980 15. /build/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) @ 0x000000001621208e 16. /build/src/Storages/StorageReplicatedMergeTree.cpp:5228: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl[abi:se190107] const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000015f9a5fe 17. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000015ed8bfd 18. /build/src/Storages/StorageReplicatedMergeTree.cpp:2514: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x0000000015ec9aab 19. /build/src/Storages/StorageReplicatedMergeTree.cpp:2349: DB::StorageReplicatedMergeTree::executeLogEntry(DB::ReplicatedMergeTreeLogEntry&) @ 0x0000000015eba91b 20. /build/src/Storages/StorageReplicatedMergeTree.cpp:3876: bool std::__function::__policy_invoker&)>::__call_impl[abi:se190107])::$_1, bool (std::shared_ptr&)>>(std::__function::__policy_storage const*, std::shared_ptr&) @ 0x0000000015f9837e 21. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000165d6fc3 22. /build/src/Storages/StorageReplicatedMergeTree.cpp:3872: DB::StorageReplicatedMergeTree::processQueueEntry(std::shared_ptr) @ 0x0000000015efc18a 23. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001624c1b2 24. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000162f9c70 25. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x00000000162fa55a 26. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc6653 27. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000000fccc4c3 28. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc3d92 29. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fcca080 30. ? @ 0x00007fbc6213eac3 31. ? @ 0x00007fbc621d0850 (version 25.3.6.10636.altinitytest (altinity build)) 2025.07.28 11:59:47.200321 [ 3974 ] {} test_13.rmt2 (7f9b740d-015c-470e-8cc6-8ba33be0dc63): auto DB::StorageReplicatedMergeTree::processQueueEntry(ReplicatedMergeTreeQueue::SelectedEntryPtr)::(anonymous class)::operator()(LogEntryPtr &) const: Code: 86. DB::HTTPException: Received error from remote server http://146b4357c08d:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Ftest%2F01165%2Ftest_13%2Frmt%2Freplicas%2F1&part=20250728_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.6.10636.altinitytest (altinity build)) '. (RECEIVED_ERROR_FROM_REMOTE_IO_SERVER), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.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 const&, int&&, String const&, unsigned long&&, String const&) @ 0x000000000feda8d9 4. /build/src/IO/HTTPCommon.cpp:104: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x000000000feda6e2 5. /build/src/IO/HTTPCommon.cpp:93: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x000000000feda537 6. /build/src/IO/ReadWriteBufferFromHTTP.cpp:277: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x000000001184a4c4 7. /build/src/IO/ReadWriteBufferFromHTTP.cpp:285: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x000000001184a615 8. /build/src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x000000001184ae59 9. /build/src/IO/ReadWriteBufferFromHTTP.cpp:472: void std::__function::__policy_invoker::__call_impl[abi:se190107]>(std::__function::__policy_storage const*) @ 0x000000001184cedd 10. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001184858b 11. /build/src/IO/ReadWriteBufferFromHTTP.cpp:465: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x000000001184bf0b 12. /build/src/IO/ReadBuffer.h:60: DB::ReadBuffer::next() @ 0x000000000a148c7b 13. /build/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) @ 0x0000000011849fb2 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]>&)>&, 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&) @ 0x0000000011841980 15. /build/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) @ 0x000000001621208e 16. /build/src/Storages/StorageReplicatedMergeTree.cpp:5228: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl[abi:se190107] const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000015f9a5fe 17. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000015ed8bfd 18. /build/src/Storages/StorageReplicatedMergeTree.cpp:2514: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x0000000015ec9aab 19. /build/src/Storages/StorageReplicatedMergeTree.cpp:2349: DB::StorageReplicatedMergeTree::executeLogEntry(DB::ReplicatedMergeTreeLogEntry&) @ 0x0000000015eba91b 20. /build/src/Storages/StorageReplicatedMergeTree.cpp:3876: bool std::__function::__policy_invoker&)>::__call_impl[abi:se190107])::$_1, bool (std::shared_ptr&)>>(std::__function::__policy_storage const*, std::shared_ptr&) @ 0x0000000015f9837e 21. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000165d6fc3 22. /build/src/Storages/StorageReplicatedMergeTree.cpp:3872: DB::StorageReplicatedMergeTree::processQueueEntry(std::shared_ptr) @ 0x0000000015efc18a 23. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001624c1b2 24. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000162f9c70 25. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x00000000162fa55a 26. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc6653 27. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000000fccc4c3 28. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc3d92 29. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fcca080 30. ? @ 0x00007fbc6213eac3 31. ? @ 0x00007fbc621d0850 (version 25.3.6.10636.altinitytest (altinity build)) 2025.07.28 11:59:47.828536 [ 3967 ] {} test_13.rmt2 (7f9b740d-015c-470e-8cc6-8ba33be0dc63): auto DB::StorageReplicatedMergeTree::processQueueEntry(ReplicatedMergeTreeQueue::SelectedEntryPtr)::(anonymous class)::operator()(LogEntryPtr &) const: Code: 86. DB::HTTPException: Received error from remote server http://146b4357c08d:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Ftest%2F01165%2Ftest_13%2Frmt%2Freplicas%2F1&part=20250728_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.6.10636.altinitytest (altinity build)) '. (RECEIVED_ERROR_FROM_REMOTE_IO_SERVER), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.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 const&, int&&, String const&, unsigned long&&, String const&) @ 0x000000000feda8d9 4. /build/src/IO/HTTPCommon.cpp:104: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x000000000feda6e2 5. /build/src/IO/HTTPCommon.cpp:93: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x000000000feda537 6. /build/src/IO/ReadWriteBufferFromHTTP.cpp:277: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x000000001184a4c4 7. /build/src/IO/ReadWriteBufferFromHTTP.cpp:285: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x000000001184a615 8. /build/src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x000000001184ae59 9. /build/src/IO/ReadWriteBufferFromHTTP.cpp:472: void std::__function::__policy_invoker::__call_impl[abi:se190107]>(std::__function::__policy_storage const*) @ 0x000000001184cedd 10. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001184858b 11. /build/src/IO/ReadWriteBufferFromHTTP.cpp:465: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x000000001184bf0b 12. /build/src/IO/ReadBuffer.h:60: DB::ReadBuffer::next() @ 0x000000000a148c7b 13. /build/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) @ 0x0000000011849fb2 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]>&)>&, 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&) @ 0x0000000011841980 15. /build/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) @ 0x000000001621208e 16. /build/src/Storages/StorageReplicatedMergeTree.cpp:5228: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl[abi:se190107] const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000015f9a5fe 17. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000015ed8bfd 18. /build/src/Storages/StorageReplicatedMergeTree.cpp:2514: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x0000000015ec9aab 19. /build/src/Storages/StorageReplicatedMergeTree.cpp:2349: DB::StorageReplicatedMergeTree::executeLogEntry(DB::ReplicatedMergeTreeLogEntry&) @ 0x0000000015eba91b 20. /build/src/Storages/StorageReplicatedMergeTree.cpp:3876: bool std::__function::__policy_invoker&)>::__call_impl[abi:se190107])::$_1, bool (std::shared_ptr&)>>(std::__function::__policy_storage const*, std::shared_ptr&) @ 0x0000000015f9837e 21. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000165d6fc3 22. /build/src/Storages/StorageReplicatedMergeTree.cpp:3872: DB::StorageReplicatedMergeTree::processQueueEntry(std::shared_ptr) @ 0x0000000015efc18a 23. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001624c1b2 24. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000162f9c70 25. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x00000000162fa55a 26. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc6653 27. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000000fccc4c3 28. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc3d92 29. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fcca080 30. ? @ 0x00007fbc6213eac3 31. ? @ 0x00007fbc621d0850 (version 25.3.6.10636.altinitytest (altinity build)) 2025.07.28 11:59:48.246362 [ 3970 ] {} test_13.rmt2 (7f9b740d-015c-470e-8cc6-8ba33be0dc63): auto DB::StorageReplicatedMergeTree::processQueueEntry(ReplicatedMergeTreeQueue::SelectedEntryPtr)::(anonymous class)::operator()(LogEntryPtr &) const: Code: 86. DB::HTTPException: Received error from remote server http://146b4357c08d:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Ftest%2F01165%2Ftest_13%2Frmt%2Freplicas%2F1&part=20250728_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.6.10636.altinitytest (altinity build)) '. (RECEIVED_ERROR_FROM_REMOTE_IO_SERVER), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.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 const&, int&&, String const&, unsigned long&&, String const&) @ 0x000000000feda8d9 4. /build/src/IO/HTTPCommon.cpp:104: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x000000000feda6e2 5. /build/src/IO/HTTPCommon.cpp:93: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x000000000feda537 6. /build/src/IO/ReadWriteBufferFromHTTP.cpp:277: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x000000001184a4c4 7. /build/src/IO/ReadWriteBufferFromHTTP.cpp:285: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x000000001184a615 8. /build/src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x000000001184ae59 9. /build/src/IO/ReadWriteBufferFromHTTP.cpp:472: void std::__function::__policy_invoker::__call_impl[abi:se190107]>(std::__function::__policy_storage const*) @ 0x000000001184cedd 10. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001184858b 11. /build/src/IO/ReadWriteBufferFromHTTP.cpp:465: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x000000001184bf0b 12. /build/src/IO/ReadBuffer.h:60: DB::ReadBuffer::next() @ 0x000000000a148c7b 13. /build/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) @ 0x0000000011849fb2 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]>&)>&, 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&) @ 0x0000000011841980 15. /build/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) @ 0x000000001621208e 16. /build/src/Storages/StorageReplicatedMergeTree.cpp:5228: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl[abi:se190107] const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000015f9a5fe 17. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000015ed8bfd 18. /build/src/Storages/StorageReplicatedMergeTree.cpp:2514: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x0000000015ec9aab 19. /build/src/Storages/StorageReplicatedMergeTree.cpp:2349: DB::StorageReplicatedMergeTree::executeLogEntry(DB::ReplicatedMergeTreeLogEntry&) @ 0x0000000015eba91b 20. /build/src/Storages/StorageReplicatedMergeTree.cpp:3876: bool std::__function::__policy_invoker&)>::__call_impl[abi:se190107])::$_1, bool (std::shared_ptr&)>>(std::__function::__policy_storage const*, std::shared_ptr&) @ 0x0000000015f9837e 21. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000165d6fc3 22. /build/src/Storages/StorageReplicatedMergeTree.cpp:3872: DB::StorageReplicatedMergeTree::processQueueEntry(std::shared_ptr) @ 0x0000000015efc18a 23. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001624c1b2 24. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000162f9c70 25. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x00000000162fa55a 26. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc6653 27. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000000fccc4c3 28. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc3d92 29. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fcca080 30. ? @ 0x00007fbc6213eac3 31. ? @ 0x00007fbc621d0850 (version 25.3.6.10636.altinitytest (altinity build)) 2025.07.28 11:59:49.204411 [ 3964 ] {} test_13.rmt2 (7f9b740d-015c-470e-8cc6-8ba33be0dc63): auto DB::StorageReplicatedMergeTree::processQueueEntry(ReplicatedMergeTreeQueue::SelectedEntryPtr)::(anonymous class)::operator()(LogEntryPtr &) const: Code: 86. DB::HTTPException: Received error from remote server http://146b4357c08d:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Ftest%2F01165%2Ftest_13%2Frmt%2Freplicas%2F1&part=20250728_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.6.10636.altinitytest (altinity build)) '. (RECEIVED_ERROR_FROM_REMOTE_IO_SERVER), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.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 const&, int&&, String const&, unsigned long&&, String const&) @ 0x000000000feda8d9 4. /build/src/IO/HTTPCommon.cpp:104: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x000000000feda6e2 5. /build/src/IO/HTTPCommon.cpp:93: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x000000000feda537 6. /build/src/IO/ReadWriteBufferFromHTTP.cpp:277: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x000000001184a4c4 7. /build/src/IO/ReadWriteBufferFromHTTP.cpp:285: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x000000001184a615 8. /build/src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x000000001184ae59 9. /build/src/IO/ReadWriteBufferFromHTTP.cpp:472: void std::__function::__policy_invoker::__call_impl[abi:se190107]>(std::__function::__policy_storage const*) @ 0x000000001184cedd 10. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001184858b 11. /build/src/IO/ReadWriteBufferFromHTTP.cpp:465: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x000000001184bf0b 12. /build/src/IO/ReadBuffer.h:60: DB::ReadBuffer::next() @ 0x000000000a148c7b 13. /build/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) @ 0x0000000011849fb2 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]>&)>&, 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&) @ 0x0000000011841980 15. /build/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) @ 0x000000001621208e 16. /build/src/Storages/StorageReplicatedMergeTree.cpp:5228: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl[abi:se190107] const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000015f9a5fe 17. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000015ed8bfd 18. /build/src/Storages/StorageReplicatedMergeTree.cpp:2514: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x0000000015ec9aab 19. /build/src/Storages/StorageReplicatedMergeTree.cpp:2349: DB::StorageReplicatedMergeTree::executeLogEntry(DB::ReplicatedMergeTreeLogEntry&) @ 0x0000000015eba91b 20. /build/src/Storages/StorageReplicatedMergeTree.cpp:3876: bool std::__function::__policy_invoker&)>::__call_impl[abi:se190107])::$_1, bool (std::shared_ptr&)>>(std::__function::__policy_storage const*, std::shared_ptr&) @ 0x0000000015f9837e 21. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000165d6fc3 22. /build/src/Storages/StorageReplicatedMergeTree.cpp:3872: DB::StorageReplicatedMergeTree::processQueueEntry(std::shared_ptr) @ 0x0000000015efc18a 23. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001624c1b2 24. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000162f9c70 25. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x00000000162fa55a 26. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc6653 27. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000000fccc4c3 28. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc3d92 29. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fcca080 30. ? @ 0x00007fbc6213eac3 31. ? @ 0x00007fbc621d0850 (version 25.3.6.10636.altinitytest (altinity build)) 2025.07.28 11:59:49.673946 [ 3961 ] {} test_13.rmt2 (7f9b740d-015c-470e-8cc6-8ba33be0dc63): auto DB::StorageReplicatedMergeTree::processQueueEntry(ReplicatedMergeTreeQueue::SelectedEntryPtr)::(anonymous class)::operator()(LogEntryPtr &) const: Code: 86. DB::HTTPException: Received error from remote server http://146b4357c08d:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Ftest%2F01165%2Ftest_13%2Frmt%2Freplicas%2F1&part=20250728_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.6.10636.altinitytest (altinity build)) '. (RECEIVED_ERROR_FROM_REMOTE_IO_SERVER), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.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 const&, int&&, String const&, unsigned long&&, String const&) @ 0x000000000feda8d9 4. /build/src/IO/HTTPCommon.cpp:104: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x000000000feda6e2 5. /build/src/IO/HTTPCommon.cpp:93: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x000000000feda537 6. /build/src/IO/ReadWriteBufferFromHTTP.cpp:277: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x000000001184a4c4 7. /build/src/IO/ReadWriteBufferFromHTTP.cpp:285: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x000000001184a615 8. /build/src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x000000001184ae59 9. /build/src/IO/ReadWriteBufferFromHTTP.cpp:472: void std::__function::__policy_invoker::__call_impl[abi:se190107]>(std::__function::__policy_storage const*) @ 0x000000001184cedd 10. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001184858b 11. /build/src/IO/ReadWriteBufferFromHTTP.cpp:465: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x000000001184bf0b 12. /build/src/IO/ReadBuffer.h:60: DB::ReadBuffer::next() @ 0x000000000a148c7b 13. /build/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) @ 0x0000000011849fb2 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]>&)>&, 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&) @ 0x0000000011841980 15. /build/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) @ 0x000000001621208e 16. /build/src/Storages/StorageReplicatedMergeTree.cpp:5228: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl[abi:se190107] const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000015f9a5fe 17. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000015ed8bfd 18. /build/src/Storages/StorageReplicatedMergeTree.cpp:2514: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x0000000015ec9aab 19. /build/src/Storages/StorageReplicatedMergeTree.cpp:2349: DB::StorageReplicatedMergeTree::executeLogEntry(DB::ReplicatedMergeTreeLogEntry&) @ 0x0000000015eba91b 20. /build/src/Storages/StorageReplicatedMergeTree.cpp:3876: bool std::__function::__policy_invoker&)>::__call_impl[abi:se190107])::$_1, bool (std::shared_ptr&)>>(std::__function::__policy_storage const*, std::shared_ptr&) @ 0x0000000015f9837e 21. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000165d6fc3 22. /build/src/Storages/StorageReplicatedMergeTree.cpp:3872: DB::StorageReplicatedMergeTree::processQueueEntry(std::shared_ptr) @ 0x0000000015efc18a 23. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001624c1b2 24. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000162f9c70 25. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x00000000162fa55a 26. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc6653 27. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000000fccc4c3 28. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc3d92 29. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fcca080 30. ? @ 0x00007fbc6213eac3 31. ? @ 0x00007fbc621d0850 (version 25.3.6.10636.altinitytest (altinity build)) 2025.07.28 11:59:50.016353 [ 3965 ] {} test_13.rmt2 (7f9b740d-015c-470e-8cc6-8ba33be0dc63): auto DB::StorageReplicatedMergeTree::processQueueEntry(ReplicatedMergeTreeQueue::SelectedEntryPtr)::(anonymous class)::operator()(LogEntryPtr &) const: Code: 86. DB::HTTPException: Received error from remote server http://146b4357c08d:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Ftest%2F01165%2Ftest_13%2Frmt%2Freplicas%2F1&part=20250728_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.6.10636.altinitytest (altinity build)) '. (RECEIVED_ERROR_FROM_REMOTE_IO_SERVER), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.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 const&, int&&, String const&, unsigned long&&, String const&) @ 0x000000000feda8d9 4. /build/src/IO/HTTPCommon.cpp:104: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x000000000feda6e2 5. /build/src/IO/HTTPCommon.cpp:93: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x000000000feda537 6. /build/src/IO/ReadWriteBufferFromHTTP.cpp:277: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x000000001184a4c4 7. /build/src/IO/ReadWriteBufferFromHTTP.cpp:285: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x000000001184a615 8. /build/src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x000000001184ae59 9. /build/src/IO/ReadWriteBufferFromHTTP.cpp:472: void std::__function::__policy_invoker::__call_impl[abi:se190107]>(std::__function::__policy_storage const*) @ 0x000000001184cedd 10. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001184858b 11. /build/src/IO/ReadWriteBufferFromHTTP.cpp:465: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x000000001184bf0b 12. /build/src/IO/ReadBuffer.h:60: DB::ReadBuffer::next() @ 0x000000000a148c7b 13. /build/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) @ 0x0000000011849fb2 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]>&)>&, 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&) @ 0x0000000011841980 15. /build/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) @ 0x000000001621208e 16. /build/src/Storages/StorageReplicatedMergeTree.cpp:5228: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl[abi:se190107] const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000015f9a5fe 17. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000015ed8bfd 18. /build/src/Storages/StorageReplicatedMergeTree.cpp:2514: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x0000000015ec9aab 19. /build/src/Storages/StorageReplicatedMergeTree.cpp:2349: DB::StorageReplicatedMergeTree::executeLogEntry(DB::ReplicatedMergeTreeLogEntry&) @ 0x0000000015eba91b 20. /build/src/Storages/StorageReplicatedMergeTree.cpp:3876: bool std::__function::__policy_invoker&)>::__call_impl[abi:se190107])::$_1, bool (std::shared_ptr&)>>(std::__function::__policy_storage const*, std::shared_ptr&) @ 0x0000000015f9837e 21. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000165d6fc3 22. /build/src/Storages/StorageReplicatedMergeTree.cpp:3872: DB::StorageReplicatedMergeTree::processQueueEntry(std::shared_ptr) @ 0x0000000015efc18a 23. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001624c1b2 24. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000162f9c70 25. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x00000000162fa55a 26. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc6653 27. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000000fccc4c3 28. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc3d92 29. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fcca080 30. ? @ 0x00007fbc6213eac3 31. ? @ 0x00007fbc621d0850 (version 25.3.6.10636.altinitytest (altinity build)) 2025.07.28 11:59:51.101266 [ 3976 ] {} test_13.rmt2 (7f9b740d-015c-470e-8cc6-8ba33be0dc63): auto DB::StorageReplicatedMergeTree::processQueueEntry(ReplicatedMergeTreeQueue::SelectedEntryPtr)::(anonymous class)::operator()(LogEntryPtr &) const: Code: 86. DB::HTTPException: Received error from remote server http://146b4357c08d:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Ftest%2F01165%2Ftest_13%2Frmt%2Freplicas%2F1&part=20250728_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.6.10636.altinitytest (altinity build)) '. (RECEIVED_ERROR_FROM_REMOTE_IO_SERVER), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.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 const&, int&&, String const&, unsigned long&&, String const&) @ 0x000000000feda8d9 4. /build/src/IO/HTTPCommon.cpp:104: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x000000000feda6e2 5. /build/src/IO/HTTPCommon.cpp:93: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x000000000feda537 6. /build/src/IO/ReadWriteBufferFromHTTP.cpp:277: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x000000001184a4c4 7. /build/src/IO/ReadWriteBufferFromHTTP.cpp:285: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x000000001184a615 8. /build/src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x000000001184ae59 9. /build/src/IO/ReadWriteBufferFromHTTP.cpp:472: void std::__function::__policy_invoker::__call_impl[abi:se190107]>(std::__function::__policy_storage const*) @ 0x000000001184cedd 10. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001184858b 11. /build/src/IO/ReadWriteBufferFromHTTP.cpp:465: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x000000001184bf0b 12. /build/src/IO/ReadBuffer.h:60: DB::ReadBuffer::next() @ 0x000000000a148c7b 13. /build/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) @ 0x0000000011849fb2 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]>&)>&, 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&) @ 0x0000000011841980 15. /build/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) @ 0x000000001621208e 16. /build/src/Storages/StorageReplicatedMergeTree.cpp:5228: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl[abi:se190107] const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000015f9a5fe 17. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000015ed8bfd 18. /build/src/Storages/StorageReplicatedMergeTree.cpp:2514: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x0000000015ec9aab 19. /build/src/Storages/StorageReplicatedMergeTree.cpp:2349: DB::StorageReplicatedMergeTree::executeLogEntry(DB::ReplicatedMergeTreeLogEntry&) @ 0x0000000015eba91b 20. /build/src/Storages/StorageReplicatedMergeTree.cpp:3876: bool std::__function::__policy_invoker&)>::__call_impl[abi:se190107])::$_1, bool (std::shared_ptr&)>>(std::__function::__policy_storage const*, std::shared_ptr&) @ 0x0000000015f9837e 21. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000165d6fc3 22. /build/src/Storages/StorageReplicatedMergeTree.cpp:3872: DB::StorageReplicatedMergeTree::processQueueEntry(std::shared_ptr) @ 0x0000000015efc18a 23. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001624c1b2 24. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000162f9c70 25. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x00000000162fa55a 26. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc6653 27. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000000fccc4c3 28. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc3d92 29. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fcca080 30. ? @ 0x00007fbc6213eac3 31. ? @ 0x00007fbc621d0850 (version 25.3.6.10636.altinitytest (altinity build)) 2025.07.28 11:59:51.539055 [ 3970 ] {} test_13.rmt2 (7f9b740d-015c-470e-8cc6-8ba33be0dc63): auto DB::StorageReplicatedMergeTree::processQueueEntry(ReplicatedMergeTreeQueue::SelectedEntryPtr)::(anonymous class)::operator()(LogEntryPtr &) const: Code: 86. DB::HTTPException: Received error from remote server http://146b4357c08d:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Ftest%2F01165%2Ftest_13%2Frmt%2Freplicas%2F1&part=20250728_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.6.10636.altinitytest (altinity build)) '. (RECEIVED_ERROR_FROM_REMOTE_IO_SERVER), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.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 const&, int&&, String const&, unsigned long&&, String const&) @ 0x000000000feda8d9 4. /build/src/IO/HTTPCommon.cpp:104: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x000000000feda6e2 5. /build/src/IO/HTTPCommon.cpp:93: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x000000000feda537 6. /build/src/IO/ReadWriteBufferFromHTTP.cpp:277: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x000000001184a4c4 7. /build/src/IO/ReadWriteBufferFromHTTP.cpp:285: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x000000001184a615 8. /build/src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x000000001184ae59 9. /build/src/IO/ReadWriteBufferFromHTTP.cpp:472: void std::__function::__policy_invoker::__call_impl[abi:se190107]>(std::__function::__policy_storage const*) @ 0x000000001184cedd 10. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001184858b 11. /build/src/IO/ReadWriteBufferFromHTTP.cpp:465: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x000000001184bf0b 12. /build/src/IO/ReadBuffer.h:60: DB::ReadBuffer::next() @ 0x000000000a148c7b 13. /build/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) @ 0x0000000011849fb2 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]>&)>&, 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&) @ 0x0000000011841980 15. /build/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) @ 0x000000001621208e 16. /build/src/Storages/StorageReplicatedMergeTree.cpp:5228: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl[abi:se190107] const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000015f9a5fe 17. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000015ed8bfd 18. /build/src/Storages/StorageReplicatedMergeTree.cpp:2514: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x0000000015ec9aab 19. /build/src/Storages/StorageReplicatedMergeTree.cpp:2349: DB::StorageReplicatedMergeTree::executeLogEntry(DB::ReplicatedMergeTreeLogEntry&) @ 0x0000000015eba91b 20. /build/src/Storages/StorageReplicatedMergeTree.cpp:3876: bool std::__function::__policy_invoker&)>::__call_impl[abi:se190107])::$_1, bool (std::shared_ptr&)>>(std::__function::__policy_storage const*, std::shared_ptr&) @ 0x0000000015f9837e 21. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000165d6fc3 22. /build/src/Storages/StorageReplicatedMergeTree.cpp:3872: DB::StorageReplicatedMergeTree::processQueueEntry(std::shared_ptr) @ 0x0000000015efc18a 23. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001624c1b2 24. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000162f9c70 25. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x00000000162fa55a 26. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc6653 27. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000000fccc4c3 28. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc3d92 29. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fcca080 30. ? @ 0x00007fbc6213eac3 31. ? @ 0x00007fbc621d0850 (version 25.3.6.10636.altinitytest (altinity build)) 2025.07.28 11:59:51.823321 [ 3962 ] {} test_13.rmt2 (7f9b740d-015c-470e-8cc6-8ba33be0dc63): auto DB::StorageReplicatedMergeTree::processQueueEntry(ReplicatedMergeTreeQueue::SelectedEntryPtr)::(anonymous class)::operator()(LogEntryPtr &) const: Code: 86. DB::HTTPException: Received error from remote server http://146b4357c08d:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Ftest%2F01165%2Ftest_13%2Frmt%2Freplicas%2F1&part=20250728_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.6.10636.altinitytest (altinity build)) '. (RECEIVED_ERROR_FROM_REMOTE_IO_SERVER), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.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 const&, int&&, String const&, unsigned long&&, String const&) @ 0x000000000feda8d9 4. /build/src/IO/HTTPCommon.cpp:104: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x000000000feda6e2 5. /build/src/IO/HTTPCommon.cpp:93: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x000000000feda537 6. /build/src/IO/ReadWriteBufferFromHTTP.cpp:277: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x000000001184a4c4 7. /build/src/IO/ReadWriteBufferFromHTTP.cpp:285: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x000000001184a615 8. /build/src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x000000001184ae59 9. /build/src/IO/ReadWriteBufferFromHTTP.cpp:472: void std::__function::__policy_invoker::__call_impl[abi:se190107]>(std::__function::__policy_storage const*) @ 0x000000001184cedd 10. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001184858b 11. /build/src/IO/ReadWriteBufferFromHTTP.cpp:465: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x000000001184bf0b 12. /build/src/IO/ReadBuffer.h:60: DB::ReadBuffer::next() @ 0x000000000a148c7b 13. /build/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) @ 0x0000000011849fb2 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]>&)>&, 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&) @ 0x0000000011841980 15. /build/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) @ 0x000000001621208e 16. /build/src/Storages/StorageReplicatedMergeTree.cpp:5228: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl[abi:se190107] const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000015f9a5fe 17. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000015ed8bfd 18. /build/src/Storages/StorageReplicatedMergeTree.cpp:2514: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x0000000015ec9aab 19. /build/src/Storages/StorageReplicatedMergeTree.cpp:2349: DB::StorageReplicatedMergeTree::executeLogEntry(DB::ReplicatedMergeTreeLogEntry&) @ 0x0000000015eba91b 20. /build/src/Storages/StorageReplicatedMergeTree.cpp:3876: bool std::__function::__policy_invoker&)>::__call_impl[abi:se190107])::$_1, bool (std::shared_ptr&)>>(std::__function::__policy_storage const*, std::shared_ptr&) @ 0x0000000015f9837e 21. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000165d6fc3 22. /build/src/Storages/StorageReplicatedMergeTree.cpp:3872: DB::StorageReplicatedMergeTree::processQueueEntry(std::shared_ptr) @ 0x0000000015efc18a 23. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001624c1b2 24. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000162f9c70 25. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x00000000162fa55a 26. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc6653 27. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000000fccc4c3 28. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc3d92 29. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fcca080 30. ? @ 0x00007fbc6213eac3 31. ? @ 0x00007fbc621d0850 (version 25.3.6.10636.altinitytest (altinity build)) 2025.07.28 11:59:52.707227 [ 3964 ] {} test_13.rmt2 (7f9b740d-015c-470e-8cc6-8ba33be0dc63): auto DB::StorageReplicatedMergeTree::processQueueEntry(ReplicatedMergeTreeQueue::SelectedEntryPtr)::(anonymous class)::operator()(LogEntryPtr &) const: Code: 86. DB::HTTPException: Received error from remote server http://146b4357c08d:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Ftest%2F01165%2Ftest_13%2Frmt%2Freplicas%2F1&part=20250728_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.6.10636.altinitytest (altinity build)) '. (RECEIVED_ERROR_FROM_REMOTE_IO_SERVER), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.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 const&, int&&, String const&, unsigned long&&, String const&) @ 0x000000000feda8d9 4. /build/src/IO/HTTPCommon.cpp:104: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x000000000feda6e2 5. /build/src/IO/HTTPCommon.cpp:93: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x000000000feda537 6. /build/src/IO/ReadWriteBufferFromHTTP.cpp:277: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x000000001184a4c4 7. /build/src/IO/ReadWriteBufferFromHTTP.cpp:285: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x000000001184a615 8. /build/src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x000000001184ae59 9. /build/src/IO/ReadWriteBufferFromHTTP.cpp:472: void std::__function::__policy_invoker::__call_impl[abi:se190107]>(std::__function::__policy_storage const*) @ 0x000000001184cedd 10. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001184858b 11. /build/src/IO/ReadWriteBufferFromHTTP.cpp:465: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x000000001184bf0b 12. /build/src/IO/ReadBuffer.h:60: DB::ReadBuffer::next() @ 0x000000000a148c7b 13. /build/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) @ 0x0000000011849fb2 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]>&)>&, 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&) @ 0x0000000011841980 15. /build/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) @ 0x000000001621208e 16. /build/src/Storages/StorageReplicatedMergeTree.cpp:5228: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl[abi:se190107] const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000015f9a5fe 17. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000015ed8bfd 18. /build/src/Storages/StorageReplicatedMergeTree.cpp:2514: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x0000000015ec9aab 19. /build/src/Storages/StorageReplicatedMergeTree.cpp:2349: DB::StorageReplicatedMergeTree::executeLogEntry(DB::ReplicatedMergeTreeLogEntry&) @ 0x0000000015eba91b 20. /build/src/Storages/StorageReplicatedMergeTree.cpp:3876: bool std::__function::__policy_invoker&)>::__call_impl[abi:se190107])::$_1, bool (std::shared_ptr&)>>(std::__function::__policy_storage const*, std::shared_ptr&) @ 0x0000000015f9837e 21. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000165d6fc3 22. /build/src/Storages/StorageReplicatedMergeTree.cpp:3872: DB::StorageReplicatedMergeTree::processQueueEntry(std::shared_ptr) @ 0x0000000015efc18a 23. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001624c1b2 24. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000162f9c70 25. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x00000000162fa55a 26. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc6653 27. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000000fccc4c3 28. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc3d92 29. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fcca080 30. ? @ 0x00007fbc6213eac3 31. ? @ 0x00007fbc621d0850 (version 25.3.6.10636.altinitytest (altinity build)) 2025.07.28 11:59:53.491085 [ 5951 ] {} 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. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception>&, String>(int, FormatStringHelperImpl>&>::type, std::type_identity::type>, std::basic_string_view>&, String&&) @ 0x000000001385a5eb 4. /build/src/Access/SettingsConstraints.cpp:376: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000013859b18 5. /build/src/Access/SettingsConstraints.cpp:300: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000013858faf 6. /build/src/Access/SettingsConstraints.cpp:209: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000013859223 7. /build/src/Interpreters/Context.cpp:2690: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000014436134 8. /build/src/Interpreters/Context.cpp:2729: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x000000001443662b 9. /build/src/Server/HTTPHandler.cpp:457: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000001686d165 10. /build/src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x0000000016870807 11. /build/src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x0000000016907e99 12. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 13. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 14. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 15. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 16. ? @ 0x00007fbc6213eac3 17. ? @ 0x00007fbc621d0850 (version 25.3.6.10636.altinitytest (altinity build)) 2025.07.28 11:59:53.717671 [ 3966 ] {} test_13.rmt2 (7f9b740d-015c-470e-8cc6-8ba33be0dc63): auto DB::StorageReplicatedMergeTree::processQueueEntry(ReplicatedMergeTreeQueue::SelectedEntryPtr)::(anonymous class)::operator()(LogEntryPtr &) const: Code: 86. DB::HTTPException: Received error from remote server http://146b4357c08d:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Ftest%2F01165%2Ftest_13%2Frmt%2Freplicas%2F1&part=20250728_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.6.10636.altinitytest (altinity build)) '. (RECEIVED_ERROR_FROM_REMOTE_IO_SERVER), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.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 const&, int&&, String const&, unsigned long&&, String const&) @ 0x000000000feda8d9 4. /build/src/IO/HTTPCommon.cpp:104: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x000000000feda6e2 5. /build/src/IO/HTTPCommon.cpp:93: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x000000000feda537 6. /build/src/IO/ReadWriteBufferFromHTTP.cpp:277: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x000000001184a4c4 7. /build/src/IO/ReadWriteBufferFromHTTP.cpp:285: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x000000001184a615 8. /build/src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x000000001184ae59 9. /build/src/IO/ReadWriteBufferFromHTTP.cpp:472: void std::__function::__policy_invoker::__call_impl[abi:se190107]>(std::__function::__policy_storage const*) @ 0x000000001184cedd 10. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001184858b 11. /build/src/IO/ReadWriteBufferFromHTTP.cpp:465: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x000000001184bf0b 12. /build/src/IO/ReadBuffer.h:60: DB::ReadBuffer::next() @ 0x000000000a148c7b 13. /build/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) @ 0x0000000011849fb2 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]>&)>&, 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&) @ 0x0000000011841980 15. /build/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) @ 0x000000001621208e 16. /build/src/Storages/StorageReplicatedMergeTree.cpp:5228: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl[abi:se190107] const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000015f9a5fe 17. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000015ed8bfd 18. /build/src/Storages/StorageReplicatedMergeTree.cpp:2514: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x0000000015ec9aab 19. /build/src/Storages/StorageReplicatedMergeTree.cpp:2349: DB::StorageReplicatedMergeTree::executeLogEntry(DB::ReplicatedMergeTreeLogEntry&) @ 0x0000000015eba91b 20. /build/src/Storages/StorageReplicatedMergeTree.cpp:3876: bool std::__function::__policy_invoker&)>::__call_impl[abi:se190107])::$_1, bool (std::shared_ptr&)>>(std::__function::__policy_storage const*, std::shared_ptr&) @ 0x0000000015f9837e 21. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000165d6fc3 22. /build/src/Storages/StorageReplicatedMergeTree.cpp:3872: DB::StorageReplicatedMergeTree::processQueueEntry(std::shared_ptr) @ 0x0000000015efc18a 23. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001624c1b2 24. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000162f9c70 25. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x00000000162fa55a 26. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc6653 27. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000000fccc4c3 28. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc3d92 29. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fcca080 30. ? @ 0x00007fbc6213eac3 31. ? @ 0x00007fbc621d0850 (version 25.3.6.10636.altinitytest (altinity build)) 2025.07.28 11:59:53.881825 [ 17270 ] {} TCPHandler: TCPHandler: Code: 81. DB::Exception: Database test_11 does not exist. Maybe you meant test_1?. (UNKNOWN_DATABASE), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000a06a8eb 4. /build/src/Interpreters/DatabaseCatalog.cpp:535: DB::DatabaseCatalog::assertDatabaseExists(String const&) const @ 0x00000000144f31f6 5. /build/src/Server/TCPHandler.cpp:342: DB::TCPHandler::runImpl() @ 0x00000000168e5a19 6. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 7. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 8. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 9. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 10. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 11. ? @ 0x00007fbc6213eac3 12. ? @ 0x00007fbc621d0850 (version 25.3.6.10636.altinitytest (altinity build)) 2025.07.28 11:59:53.894676 [ 17270 ] {} ServerErrorHandler: Code: 81. DB::Exception: Database test_11 does not exist. Maybe you meant test_1?. (UNKNOWN_DATABASE), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000a06a8eb 4. /build/src/Interpreters/DatabaseCatalog.cpp:535: DB::DatabaseCatalog::assertDatabaseExists(String const&) const @ 0x00000000144f31f6 5. /build/src/Server/TCPHandler.cpp:342: DB::TCPHandler::runImpl() @ 0x00000000168e5a19 6. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 7. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 8. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 9. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 10. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 11. ? @ 0x00007fbc6213eac3 12. ? @ 0x00007fbc621d0850 (version 25.3.6.10636.altinitytest (altinity build)) 2025.07.28 11:59:54.061376 [ 7625 ] {} TCPHandler: TCPHandler: Code: 81. DB::Exception: Database test_11 does not exist. Maybe you meant test_1?. (UNKNOWN_DATABASE), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000a06a8eb 4. /build/src/Interpreters/DatabaseCatalog.cpp:535: DB::DatabaseCatalog::assertDatabaseExists(String const&) const @ 0x00000000144f31f6 5. /build/src/Server/TCPHandler.cpp:342: DB::TCPHandler::runImpl() @ 0x00000000168e5a19 6. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 7. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 8. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 9. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 10. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 11. ? @ 0x00007fbc6213eac3 12. ? @ 0x00007fbc621d0850 (version 25.3.6.10636.altinitytest (altinity build)) 2025.07.28 11:59:54.092454 [ 7625 ] {} ServerErrorHandler: Code: 81. DB::Exception: Database test_11 does not exist. Maybe you meant test_1?. (UNKNOWN_DATABASE), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000a06a8eb 4. /build/src/Interpreters/DatabaseCatalog.cpp:535: DB::DatabaseCatalog::assertDatabaseExists(String const&) const @ 0x00000000144f31f6 5. /build/src/Server/TCPHandler.cpp:342: DB::TCPHandler::runImpl() @ 0x00000000168e5a19 6. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 7. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 8. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 9. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 10. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 11. ? @ 0x00007fbc6213eac3 12. ? @ 0x00007fbc621d0850 (version 25.3.6.10636.altinitytest (altinity build)) 2025.07.28 11:59:54.182024 [ 7625 ] {} TCPHandler: TCPHandler: Code: 81. DB::Exception: Database test_11 does not exist. Maybe you meant test_1?. (UNKNOWN_DATABASE), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000a06a8eb 4. /build/src/Interpreters/DatabaseCatalog.cpp:535: DB::DatabaseCatalog::assertDatabaseExists(String const&) const @ 0x00000000144f31f6 5. /build/src/Server/TCPHandler.cpp:342: DB::TCPHandler::runImpl() @ 0x00000000168e5a19 6. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 7. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 8. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 9. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 10. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 11. ? @ 0x00007fbc6213eac3 12. ? @ 0x00007fbc621d0850 (version 25.3.6.10636.altinitytest (altinity build)) 2025.07.28 11:59:54.182892 [ 7625 ] {} ServerErrorHandler: Code: 81. DB::Exception: Database test_11 does not exist. Maybe you meant test_1?. (UNKNOWN_DATABASE), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000a06a8eb 4. /build/src/Interpreters/DatabaseCatalog.cpp:535: DB::DatabaseCatalog::assertDatabaseExists(String const&) const @ 0x00000000144f31f6 5. /build/src/Server/TCPHandler.cpp:342: DB::TCPHandler::runImpl() @ 0x00000000168e5a19 6. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 7. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 8. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 9. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 10. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 11. ? @ 0x00007fbc6213eac3 12. ? @ 0x00007fbc621d0850 (version 25.3.6.10636.altinitytest (altinity build)) 2025.07.28 11:59:54.260752 [ 3977 ] {} test_13.rmt2 (7f9b740d-015c-470e-8cc6-8ba33be0dc63): auto DB::StorageReplicatedMergeTree::processQueueEntry(ReplicatedMergeTreeQueue::SelectedEntryPtr)::(anonymous class)::operator()(LogEntryPtr &) const: Code: 86. DB::HTTPException: Received error from remote server http://146b4357c08d:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Ftest%2F01165%2Ftest_13%2Frmt%2Freplicas%2F1&part=20250728_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.6.10636.altinitytest (altinity build)) '. (RECEIVED_ERROR_FROM_REMOTE_IO_SERVER), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.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 const&, int&&, String const&, unsigned long&&, String const&) @ 0x000000000feda8d9 4. /build/src/IO/HTTPCommon.cpp:104: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x000000000feda6e2 5. /build/src/IO/HTTPCommon.cpp:93: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x000000000feda537 6. /build/src/IO/ReadWriteBufferFromHTTP.cpp:277: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x000000001184a4c4 7. /build/src/IO/ReadWriteBufferFromHTTP.cpp:285: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x000000001184a615 8. /build/src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x000000001184ae59 9. /build/src/IO/ReadWriteBufferFromHTTP.cpp:472: void std::__function::__policy_invoker::__call_impl[abi:se190107]>(std::__function::__policy_storage const*) @ 0x000000001184cedd 10. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001184858b 11. /build/src/IO/ReadWriteBufferFromHTTP.cpp:465: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x000000001184bf0b 12. /build/src/IO/ReadBuffer.h:60: DB::ReadBuffer::next() @ 0x000000000a148c7b 13. /build/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) @ 0x0000000011849fb2 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]>&)>&, 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&) @ 0x0000000011841980 15. /build/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) @ 0x000000001621208e 16. /build/src/Storages/StorageReplicatedMergeTree.cpp:5228: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl[abi:se190107] const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000015f9a5fe 17. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000015ed8bfd 18. /build/src/Storages/StorageReplicatedMergeTree.cpp:2514: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x0000000015ec9aab 19. /build/src/Storages/StorageReplicatedMergeTree.cpp:2349: DB::StorageReplicatedMergeTree::executeLogEntry(DB::ReplicatedMergeTreeLogEntry&) @ 0x0000000015eba91b 20. /build/src/Storages/StorageReplicatedMergeTree.cpp:3876: bool std::__function::__policy_invoker&)>::__call_impl[abi:se190107])::$_1, bool (std::shared_ptr&)>>(std::__function::__policy_storage const*, std::shared_ptr&) @ 0x0000000015f9837e 21. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000165d6fc3 22. /build/src/Storages/StorageReplicatedMergeTree.cpp:3872: DB::StorageReplicatedMergeTree::processQueueEntry(std::shared_ptr) @ 0x0000000015efc18a 23. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001624c1b2 24. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000162f9c70 25. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x00000000162fa55a 26. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc6653 27. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000000fccc4c3 28. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc3d92 29. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fcca080 30. ? @ 0x00007fbc6213eac3 31. ? @ 0x00007fbc621d0850 (version 25.3.6.10636.altinitytest (altinity build)) 2025.07.28 11:59:54.336552 [ 17270 ] {} TCPHandler: TCPHandler: Code: 81. DB::Exception: Database test_11 does not exist. Maybe you meant test_1?. (UNKNOWN_DATABASE), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000a06a8eb 4. /build/src/Interpreters/DatabaseCatalog.cpp:535: DB::DatabaseCatalog::assertDatabaseExists(String const&) const @ 0x00000000144f31f6 5. /build/src/Server/TCPHandler.cpp:342: DB::TCPHandler::runImpl() @ 0x00000000168e5a19 6. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 7. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 8. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 9. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 10. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 11. ? @ 0x00007fbc6213eac3 12. ? @ 0x00007fbc621d0850 (version 25.3.6.10636.altinitytest (altinity build)) 2025.07.28 11:59:54.337533 [ 17270 ] {} ServerErrorHandler: Code: 81. DB::Exception: Database test_11 does not exist. Maybe you meant test_1?. (UNKNOWN_DATABASE), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000a06a8eb 4. /build/src/Interpreters/DatabaseCatalog.cpp:535: DB::DatabaseCatalog::assertDatabaseExists(String const&) const @ 0x00000000144f31f6 5. /build/src/Server/TCPHandler.cpp:342: DB::TCPHandler::runImpl() @ 0x00000000168e5a19 6. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 7. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 8. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 9. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 10. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 11. ? @ 0x00007fbc6213eac3 12. ? @ 0x00007fbc621d0850 (version 25.3.6.10636.altinitytest (altinity build)) 2025.07.28 11:59:54.486406 [ 7625 ] {} TCPHandler: TCPHandler: Code: 81. DB::Exception: Database test_11 does not exist. Maybe you meant test_1?. (UNKNOWN_DATABASE), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000a06a8eb 4. /build/src/Interpreters/DatabaseCatalog.cpp:535: DB::DatabaseCatalog::assertDatabaseExists(String const&) const @ 0x00000000144f31f6 5. /build/src/Server/TCPHandler.cpp:342: DB::TCPHandler::runImpl() @ 0x00000000168e5a19 6. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 7. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 8. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 9. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 10. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 11. ? @ 0x00007fbc6213eac3 12. ? @ 0x00007fbc621d0850 (version 25.3.6.10636.altinitytest (altinity build)) 2025.07.28 11:59:54.487037 [ 7625 ] {} ServerErrorHandler: Code: 81. DB::Exception: Database test_11 does not exist. Maybe you meant test_1?. (UNKNOWN_DATABASE), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000a06a8eb 4. /build/src/Interpreters/DatabaseCatalog.cpp:535: DB::DatabaseCatalog::assertDatabaseExists(String const&) const @ 0x00000000144f31f6 5. /build/src/Server/TCPHandler.cpp:342: DB::TCPHandler::runImpl() @ 0x00000000168e5a19 6. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 7. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 8. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 9. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 10. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 11. ? @ 0x00007fbc6213eac3 12. ? @ 0x00007fbc621d0850 (version 25.3.6.10636.altinitytest (altinity build)) 2025.07.28 11:59:54.649699 [ 3283 ] {} TCPHandler: TCPHandler: Code: 81. DB::Exception: Database test_11 does not exist. Maybe you meant test_1?. (UNKNOWN_DATABASE), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000a06a8eb 4. /build/src/Interpreters/DatabaseCatalog.cpp:535: DB::DatabaseCatalog::assertDatabaseExists(String const&) const @ 0x00000000144f31f6 5. /build/src/Server/TCPHandler.cpp:342: DB::TCPHandler::runImpl() @ 0x00000000168e5a19 6. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 7. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 8. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 9. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 10. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 11. ? @ 0x00007fbc6213eac3 12. ? @ 0x00007fbc621d0850 (version 25.3.6.10636.altinitytest (altinity build)) 2025.07.28 11:59:54.650718 [ 3283 ] {} ServerErrorHandler: Code: 81. DB::Exception: Database test_11 does not exist. Maybe you meant test_1?. (UNKNOWN_DATABASE), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000a06a8eb 4. /build/src/Interpreters/DatabaseCatalog.cpp:535: DB::DatabaseCatalog::assertDatabaseExists(String const&) const @ 0x00000000144f31f6 5. /build/src/Server/TCPHandler.cpp:342: DB::TCPHandler::runImpl() @ 0x00000000168e5a19 6. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 7. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 8. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 9. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 10. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 11. ? @ 0x00007fbc6213eac3 12. ? @ 0x00007fbc621d0850 (version 25.3.6.10636.altinitytest (altinity build)) 2025.07.28 11:59:54.769412 [ 5327 ] {} TCPHandler: TCPHandler: Code: 81. DB::Exception: Database test_11 does not exist. Maybe you meant test_1?. (UNKNOWN_DATABASE), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000a06a8eb 4. /build/src/Interpreters/DatabaseCatalog.cpp:535: DB::DatabaseCatalog::assertDatabaseExists(String const&) const @ 0x00000000144f31f6 5. /build/src/Server/TCPHandler.cpp:342: DB::TCPHandler::runImpl() @ 0x00000000168e5a19 6. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 7. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 8. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 9. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 10. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 11. ? @ 0x00007fbc6213eac3 12. ? @ 0x00007fbc621d0850 (version 25.3.6.10636.altinitytest (altinity build)) 2025.07.28 11:59:54.770177 [ 5327 ] {} ServerErrorHandler: Code: 81. DB::Exception: Database test_11 does not exist. Maybe you meant test_1?. (UNKNOWN_DATABASE), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000a06a8eb 4. /build/src/Interpreters/DatabaseCatalog.cpp:535: DB::DatabaseCatalog::assertDatabaseExists(String const&) const @ 0x00000000144f31f6 5. /build/src/Server/TCPHandler.cpp:342: DB::TCPHandler::runImpl() @ 0x00000000168e5a19 6. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 7. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 8. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 9. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 10. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 11. ? @ 0x00007fbc6213eac3 12. ? @ 0x00007fbc621d0850 (version 25.3.6.10636.altinitytest (altinity build)) 2025.07.28 11:59:54.846910 [ 3969 ] {} test_13.rmt2 (7f9b740d-015c-470e-8cc6-8ba33be0dc63): auto DB::StorageReplicatedMergeTree::processQueueEntry(ReplicatedMergeTreeQueue::SelectedEntryPtr)::(anonymous class)::operator()(LogEntryPtr &) const: Code: 86. DB::HTTPException: Received error from remote server http://146b4357c08d:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Ftest%2F01165%2Ftest_13%2Frmt%2Freplicas%2F1&part=20250728_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.6.10636.altinitytest (altinity build)) '. (RECEIVED_ERROR_FROM_REMOTE_IO_SERVER), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.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 const&, int&&, String const&, unsigned long&&, String const&) @ 0x000000000feda8d9 4. /build/src/IO/HTTPCommon.cpp:104: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x000000000feda6e2 5. /build/src/IO/HTTPCommon.cpp:93: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x000000000feda537 6. /build/src/IO/ReadWriteBufferFromHTTP.cpp:277: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x000000001184a4c4 7. /build/src/IO/ReadWriteBufferFromHTTP.cpp:285: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x000000001184a615 8. /build/src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x000000001184ae59 9. /build/src/IO/ReadWriteBufferFromHTTP.cpp:472: void std::__function::__policy_invoker::__call_impl[abi:se190107]>(std::__function::__policy_storage const*) @ 0x000000001184cedd 10. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001184858b 11. /build/src/IO/ReadWriteBufferFromHTTP.cpp:465: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x000000001184bf0b 12. /build/src/IO/ReadBuffer.h:60: DB::ReadBuffer::next() @ 0x000000000a148c7b 13. /build/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) @ 0x0000000011849fb2 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]>&)>&, 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&) @ 0x0000000011841980 15. /build/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) @ 0x000000001621208e 16. /build/src/Storages/StorageReplicatedMergeTree.cpp:5228: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl[abi:se190107] const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000015f9a5fe 17. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000015ed8bfd 18. /build/src/Storages/StorageReplicatedMergeTree.cpp:2514: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x0000000015ec9aab 19. /build/src/Storages/StorageReplicatedMergeTree.cpp:2349: DB::StorageReplicatedMergeTree::executeLogEntry(DB::ReplicatedMergeTreeLogEntry&) @ 0x0000000015eba91b 20. /build/src/Storages/StorageReplicatedMergeTree.cpp:3876: bool std::__function::__policy_invoker&)>::__call_impl[abi:se190107])::$_1, bool (std::shared_ptr&)>>(std::__function::__policy_storage const*, std::shared_ptr&) @ 0x0000000015f9837e 21. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000165d6fc3 22. /build/src/Storages/StorageReplicatedMergeTree.cpp:3872: DB::StorageReplicatedMergeTree::processQueueEntry(std::shared_ptr) @ 0x0000000015efc18a 23. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001624c1b2 24. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000162f9c70 25. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x00000000162fa55a 26. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc6653 27. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000000fccc4c3 28. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc3d92 29. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fcca080 30. ? @ 0x00007fbc6213eac3 31. ? @ 0x00007fbc621d0850 (version 25.3.6.10636.altinitytest (altinity build)) 2025.07.28 11:59:54.886793 [ 17270 ] {} TCPHandler: TCPHandler: Code: 81. DB::Exception: Database test_11 does not exist. Maybe you meant test_1?. (UNKNOWN_DATABASE), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000a06a8eb 4. /build/src/Interpreters/DatabaseCatalog.cpp:535: DB::DatabaseCatalog::assertDatabaseExists(String const&) const @ 0x00000000144f31f6 5. /build/src/Server/TCPHandler.cpp:342: DB::TCPHandler::runImpl() @ 0x00000000168e5a19 6. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 7. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 8. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 9. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 10. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 11. ? @ 0x00007fbc6213eac3 12. ? @ 0x00007fbc621d0850 (version 25.3.6.10636.altinitytest (altinity build)) 2025.07.28 11:59:54.891033 [ 17270 ] {} ServerErrorHandler: Code: 81. DB::Exception: Database test_11 does not exist. Maybe you meant test_1?. (UNKNOWN_DATABASE), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000a06a8eb 4. /build/src/Interpreters/DatabaseCatalog.cpp:535: DB::DatabaseCatalog::assertDatabaseExists(String const&) const @ 0x00000000144f31f6 5. /build/src/Server/TCPHandler.cpp:342: DB::TCPHandler::runImpl() @ 0x00000000168e5a19 6. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 7. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 8. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 9. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 10. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 11. ? @ 0x00007fbc6213eac3 12. ? @ 0x00007fbc621d0850 (version 25.3.6.10636.altinitytest (altinity build)) 2025.07.28 11:59:55.037746 [ 17270 ] {} TCPHandler: TCPHandler: Code: 81. DB::Exception: Database test_11 does not exist. Maybe you meant test_1?. (UNKNOWN_DATABASE), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000a06a8eb 4. /build/src/Interpreters/DatabaseCatalog.cpp:535: DB::DatabaseCatalog::assertDatabaseExists(String const&) const @ 0x00000000144f31f6 5. /build/src/Server/TCPHandler.cpp:342: DB::TCPHandler::runImpl() @ 0x00000000168e5a19 6. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 7. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 8. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 9. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 10. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 11. ? @ 0x00007fbc6213eac3 12. ? @ 0x00007fbc621d0850 (version 25.3.6.10636.altinitytest (altinity build)) 2025.07.28 11:59:55.038419 [ 17270 ] {} ServerErrorHandler: Code: 81. DB::Exception: Database test_11 does not exist. Maybe you meant test_1?. (UNKNOWN_DATABASE), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000a06a8eb 4. /build/src/Interpreters/DatabaseCatalog.cpp:535: DB::DatabaseCatalog::assertDatabaseExists(String const&) const @ 0x00000000144f31f6 5. /build/src/Server/TCPHandler.cpp:342: DB::TCPHandler::runImpl() @ 0x00000000168e5a19 6. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 7. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 8. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 9. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 10. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 11. ? @ 0x00007fbc6213eac3 12. ? @ 0x00007fbc621d0850 (version 25.3.6.10636.altinitytest (altinity build)) 2025.07.28 11:59:55.110825 [ 11826 ] {7a680810-25b8-451b-bcb6-50315e2dca45} executeQuery: Code: 36. DB::Exception: Column `path` should not be empty. (BAD_ARGUMENTS) (version 25.3.6.10636.altinitytest (altinity build)) (from [::1]:38918) (comment: 02311_system_zookeeper_insert.sql) (query 15, line 33) (in query: -- test exceptions insert into system.zookeeper (name, value) values ), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000000a074fcb 4. /build/src/Storages/System/StorageSystemZooKeeper.cpp:156: DB::ZooKeeperSink::consume(DB::Chunk&) @ 0x0000000011a848b7 5. /build/src/Processors/Sinks/SinkToStorage.cpp:10: DB::SinkToStorage::onConsume(DB::Chunk) @ 0x0000000016cee093 6. /build/src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: void std::__function::__policy_invoker::__call_impl[abi:se190107]>(std::__function::__policy_storage const*) @ 0x0000000016c0ad89 7. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000016c0abf5 8. /build/src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: DB::ExceptionKeepingTransform::work() @ 0x0000000016c0a6fe 9. /build/src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x00000000169bd00f 10. /build/src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x00000000169b2105 11. /build/src/Processors/Executors/PipelineExecutor.cpp:170: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x00000000169b16a7 12. /build/src/Processors/Executors/PushingPipelineExecutor.cpp:131: DB::PushingPipelineExecutor::finish() @ 0x00000000169c359f 13. /build/src/Server/TCPHandler.cpp:1128: DB::TCPHandler::processInsertQuery(DB::QueryState&) @ 0x00000000168f0d2c 14. /build/src/Server/TCPHandler.cpp:673: DB::TCPHandler::runImpl() @ 0x00000000168e68bc 15. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 16. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 17. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 18. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 19. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 20. ? @ 0x00007fbc6213eac3 21. ? @ 0x00007fbc621d0850 2025.07.28 11:59:55.133089 [ 11826 ] {} TCPHandler: Code: 36. DB::Exception: Column `path` should not be empty. (BAD_ARGUMENTS), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000000a074fcb 4. /build/src/Storages/System/StorageSystemZooKeeper.cpp:156: DB::ZooKeeperSink::consume(DB::Chunk&) @ 0x0000000011a848b7 5. /build/src/Processors/Sinks/SinkToStorage.cpp:10: DB::SinkToStorage::onConsume(DB::Chunk) @ 0x0000000016cee093 6. /build/src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: void std::__function::__policy_invoker::__call_impl[abi:se190107]>(std::__function::__policy_storage const*) @ 0x0000000016c0ad89 7. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000016c0abf5 8. /build/src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: DB::ExceptionKeepingTransform::work() @ 0x0000000016c0a6fe 9. /build/src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x00000000169bd00f 10. /build/src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x00000000169b2105 11. /build/src/Processors/Executors/PipelineExecutor.cpp:170: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x00000000169b16a7 12. /build/src/Processors/Executors/PushingPipelineExecutor.cpp:131: DB::PushingPipelineExecutor::finish() @ 0x00000000169c359f 13. /build/src/Server/TCPHandler.cpp:1128: DB::TCPHandler::processInsertQuery(DB::QueryState&) @ 0x00000000168f0d2c 14. /build/src/Server/TCPHandler.cpp:673: DB::TCPHandler::runImpl() @ 0x00000000168e68bc 15. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 16. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 17. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 18. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 19. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 20. ? @ 0x00007fbc6213eac3 21. ? @ 0x00007fbc621d0850 2025.07.28 11:59:55.183764 [ 7625 ] {} TCPHandler: TCPHandler: Code: 81. DB::Exception: Database test_11 does not exist. Maybe you meant test_1?. (UNKNOWN_DATABASE), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000a06a8eb 4. /build/src/Interpreters/DatabaseCatalog.cpp:535: DB::DatabaseCatalog::assertDatabaseExists(String const&) const @ 0x00000000144f31f6 5. /build/src/Server/TCPHandler.cpp:342: DB::TCPHandler::runImpl() @ 0x00000000168e5a19 6. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 7. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 8. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 9. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 10. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 11. ? @ 0x00007fbc6213eac3 12. ? @ 0x00007fbc621d0850 (version 25.3.6.10636.altinitytest (altinity build)) 2025.07.28 11:59:55.187041 [ 7625 ] {} ServerErrorHandler: Code: 81. DB::Exception: Database test_11 does not exist. Maybe you meant test_1?. (UNKNOWN_DATABASE), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000a06a8eb 4. /build/src/Interpreters/DatabaseCatalog.cpp:535: DB::DatabaseCatalog::assertDatabaseExists(String const&) const @ 0x00000000144f31f6 5. /build/src/Server/TCPHandler.cpp:342: DB::TCPHandler::runImpl() @ 0x00000000168e5a19 6. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 7. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 8. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 9. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 10. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 11. ? @ 0x00007fbc6213eac3 12. ? @ 0x00007fbc621d0850 (version 25.3.6.10636.altinitytest (altinity build)) 2025.07.28 11:59:55.289302 [ 3977 ] {} test_13.rmt2 (7f9b740d-015c-470e-8cc6-8ba33be0dc63): auto DB::StorageReplicatedMergeTree::processQueueEntry(ReplicatedMergeTreeQueue::SelectedEntryPtr)::(anonymous class)::operator()(LogEntryPtr &) const: Code: 86. DB::HTTPException: Received error from remote server http://146b4357c08d:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Ftest%2F01165%2Ftest_13%2Frmt%2Freplicas%2F1&part=20250728_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.6.10636.altinitytest (altinity build)) '. (RECEIVED_ERROR_FROM_REMOTE_IO_SERVER), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.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 const&, int&&, String const&, unsigned long&&, String const&) @ 0x000000000feda8d9 4. /build/src/IO/HTTPCommon.cpp:104: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x000000000feda6e2 5. /build/src/IO/HTTPCommon.cpp:93: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x000000000feda537 6. /build/src/IO/ReadWriteBufferFromHTTP.cpp:277: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x000000001184a4c4 7. /build/src/IO/ReadWriteBufferFromHTTP.cpp:285: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x000000001184a615 8. /build/src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x000000001184ae59 9. /build/src/IO/ReadWriteBufferFromHTTP.cpp:472: void std::__function::__policy_invoker::__call_impl[abi:se190107]>(std::__function::__policy_storage const*) @ 0x000000001184cedd 10. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001184858b 11. /build/src/IO/ReadWriteBufferFromHTTP.cpp:465: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x000000001184bf0b 12. /build/src/IO/ReadBuffer.h:60: DB::ReadBuffer::next() @ 0x000000000a148c7b 13. /build/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) @ 0x0000000011849fb2 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]>&)>&, 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&) @ 0x0000000011841980 15. /build/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) @ 0x000000001621208e 16. /build/src/Storages/StorageReplicatedMergeTree.cpp:5228: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl[abi:se190107] const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000015f9a5fe 17. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000015ed8bfd 18. /build/src/Storages/StorageReplicatedMergeTree.cpp:2514: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x0000000015ec9aab 19. /build/src/Storages/StorageReplicatedMergeTree.cpp:2349: DB::StorageReplicatedMergeTree::executeLogEntry(DB::ReplicatedMergeTreeLogEntry&) @ 0x0000000015eba91b 20. /build/src/Storages/StorageReplicatedMergeTree.cpp:3876: bool std::__function::__policy_invoker&)>::__call_impl[abi:se190107])::$_1, bool (std::shared_ptr&)>>(std::__function::__policy_storage const*, std::shared_ptr&) @ 0x0000000015f9837e 21. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000165d6fc3 22. /build/src/Storages/StorageReplicatedMergeTree.cpp:3872: DB::StorageReplicatedMergeTree::processQueueEntry(std::shared_ptr) @ 0x0000000015efc18a 23. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001624c1b2 24. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000162f9c70 25. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x00000000162fa55a 26. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc6653 27. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000000fccc4c3 28. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc3d92 29. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fcca080 30. ? @ 0x00007fbc6213eac3 31. ? @ 0x00007fbc621d0850 (version 25.3.6.10636.altinitytest (altinity build)) 2025.07.28 11:59:55.312150 [ 7625 ] {} TCPHandler: TCPHandler: Code: 81. DB::Exception: Database test_11 does not exist. Maybe you meant test_1?. (UNKNOWN_DATABASE), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000a06a8eb 4. /build/src/Interpreters/DatabaseCatalog.cpp:535: DB::DatabaseCatalog::assertDatabaseExists(String const&) const @ 0x00000000144f31f6 5. /build/src/Server/TCPHandler.cpp:342: DB::TCPHandler::runImpl() @ 0x00000000168e5a19 6. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 7. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 8. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 9. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 10. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 11. ? @ 0x00007fbc6213eac3 12. ? @ 0x00007fbc621d0850 (version 25.3.6.10636.altinitytest (altinity build)) 2025.07.28 11:59:55.312771 [ 7625 ] {} ServerErrorHandler: Code: 81. DB::Exception: Database test_11 does not exist. Maybe you meant test_1?. (UNKNOWN_DATABASE), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000a06a8eb 4. /build/src/Interpreters/DatabaseCatalog.cpp:535: DB::DatabaseCatalog::assertDatabaseExists(String const&) const @ 0x00000000144f31f6 5. /build/src/Server/TCPHandler.cpp:342: DB::TCPHandler::runImpl() @ 0x00000000168e5a19 6. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 7. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 8. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 9. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 10. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 11. ? @ 0x00007fbc6213eac3 12. ? @ 0x00007fbc621d0850 (version 25.3.6.10636.altinitytest (altinity build)) 2025.07.28 11:59:55.326885 [ 11826 ] {c3ef2000-ec1c-4c50-b7e9-ebd1fe52687a} executeQuery: Code: 36. DB::Exception: Column `name` should not be empty. (BAD_ARGUMENTS) (version 25.3.6.10636.altinitytest (altinity build)) (from [::1]:38918) (comment: 02311_system_zookeeper_insert.sql) (query 16, line 35) (in query: insert into system.zookeeper (path, value) values ), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000000a074fcb 4. /build/src/Storages/System/StorageSystemZooKeeper.cpp:151: DB::ZooKeeperSink::consume(DB::Chunk&) @ 0x0000000011a847e1 5. /build/src/Processors/Sinks/SinkToStorage.cpp:10: DB::SinkToStorage::onConsume(DB::Chunk) @ 0x0000000016cee093 6. /build/src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: void std::__function::__policy_invoker::__call_impl[abi:se190107]>(std::__function::__policy_storage const*) @ 0x0000000016c0ad89 7. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000016c0abf5 8. /build/src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: DB::ExceptionKeepingTransform::work() @ 0x0000000016c0a6fe 9. /build/src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x00000000169bd00f 10. /build/src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x00000000169b2105 11. /build/src/Processors/Executors/PipelineExecutor.cpp:170: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x00000000169b16a7 12. /build/src/Processors/Executors/PushingPipelineExecutor.cpp:131: DB::PushingPipelineExecutor::finish() @ 0x00000000169c359f 13. /build/src/Server/TCPHandler.cpp:1128: DB::TCPHandler::processInsertQuery(DB::QueryState&) @ 0x00000000168f0d2c 14. /build/src/Server/TCPHandler.cpp:673: DB::TCPHandler::runImpl() @ 0x00000000168e68bc 15. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 16. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 17. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 18. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 19. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 20. ? @ 0x00007fbc6213eac3 21. ? @ 0x00007fbc621d0850 2025.07.28 11:59:55.367995 [ 11826 ] {} TCPHandler: Code: 36. DB::Exception: Column `name` should not be empty. (BAD_ARGUMENTS), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000000a074fcb 4. /build/src/Storages/System/StorageSystemZooKeeper.cpp:151: DB::ZooKeeperSink::consume(DB::Chunk&) @ 0x0000000011a847e1 5. /build/src/Processors/Sinks/SinkToStorage.cpp:10: DB::SinkToStorage::onConsume(DB::Chunk) @ 0x0000000016cee093 6. /build/src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: void std::__function::__policy_invoker::__call_impl[abi:se190107]>(std::__function::__policy_storage const*) @ 0x0000000016c0ad89 7. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000016c0abf5 8. /build/src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: DB::ExceptionKeepingTransform::work() @ 0x0000000016c0a6fe 9. /build/src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x00000000169bd00f 10. /build/src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x00000000169b2105 11. /build/src/Processors/Executors/PipelineExecutor.cpp:170: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x00000000169b16a7 12. /build/src/Processors/Executors/PushingPipelineExecutor.cpp:131: DB::PushingPipelineExecutor::finish() @ 0x00000000169c359f 13. /build/src/Server/TCPHandler.cpp:1128: DB::TCPHandler::processInsertQuery(DB::QueryState&) @ 0x00000000168f0d2c 14. /build/src/Server/TCPHandler.cpp:673: DB::TCPHandler::runImpl() @ 0x00000000168e68bc 15. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 16. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 17. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 18. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 19. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 20. ? @ 0x00007fbc6213eac3 21. ? @ 0x00007fbc621d0850 2025.07.28 11:59:55.434296 [ 5327 ] {} TCPHandler: TCPHandler: Code: 81. DB::Exception: Database test_11 does not exist. Maybe you meant test_1?. (UNKNOWN_DATABASE), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000a06a8eb 4. /build/src/Interpreters/DatabaseCatalog.cpp:535: DB::DatabaseCatalog::assertDatabaseExists(String const&) const @ 0x00000000144f31f6 5. /build/src/Server/TCPHandler.cpp:342: DB::TCPHandler::runImpl() @ 0x00000000168e5a19 6. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 7. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 8. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 9. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 10. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 11. ? @ 0x00007fbc6213eac3 12. ? @ 0x00007fbc621d0850 (version 25.3.6.10636.altinitytest (altinity build)) 2025.07.28 11:59:55.435420 [ 5327 ] {} ServerErrorHandler: Code: 81. DB::Exception: Database test_11 does not exist. Maybe you meant test_1?. (UNKNOWN_DATABASE), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000a06a8eb 4. /build/src/Interpreters/DatabaseCatalog.cpp:535: DB::DatabaseCatalog::assertDatabaseExists(String const&) const @ 0x00000000144f31f6 5. /build/src/Server/TCPHandler.cpp:342: DB::TCPHandler::runImpl() @ 0x00000000168e5a19 6. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 7. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 8. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 9. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 10. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 11. ? @ 0x00007fbc6213eac3 12. ? @ 0x00007fbc621d0850 (version 25.3.6.10636.altinitytest (altinity build)) 2025.07.28 11:59:55.442051 [ 11826 ] {f5ba51fd-fdf2-4a04-a17a-1dae1e71d6ce} executeQuery: Code: 44. DB::Exception: Cannot insert column version, because it is MATERIALIZED column. (ILLEGAL_COLUMN) (version 25.3.6.10636.altinitytest (altinity build)) (from [::1]:38918) (comment: 02311_system_zookeeper_insert.sql) (query 17, line 36) (in query: insert into system.zookeeper (name, version) values ), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000a9b78ab 4. /build/src/Interpreters/InterpreterInsertQuery.cpp:248: DB::InterpreterInsertQuery::getSampleBlockImpl(std::vector> const&, std::shared_ptr const&, std::shared_ptr const&, bool, bool) @ 0x000000001492ce53 5. /build/src/Interpreters/InterpreterInsertQuery.cpp:200: DB::InterpreterInsertQuery::getSampleBlock(DB::ASTInsertQuery const&, std::shared_ptr const&, std::shared_ptr const&, std::shared_ptr, bool, bool) @ 0x000000001492c400 6. /build/src/Interpreters/InterpreterInsertQuery.cpp:838: DB::InterpreterInsertQuery::execute() @ 0x0000000014933ae7 7. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88dc9 8. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 9. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 10. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 11. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 12. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 13. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 14. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 15. ? @ 0x00007fbc6213eac3 16. ? @ 0x00007fbc621d0850 2025.07.28 11:59:55.448695 [ 11826 ] {} TCPHandler: Code: 44. DB::Exception: Cannot insert column version, because it is MATERIALIZED column. (ILLEGAL_COLUMN), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000a9b78ab 4. /build/src/Interpreters/InterpreterInsertQuery.cpp:248: DB::InterpreterInsertQuery::getSampleBlockImpl(std::vector> const&, std::shared_ptr const&, std::shared_ptr const&, bool, bool) @ 0x000000001492ce53 5. /build/src/Interpreters/InterpreterInsertQuery.cpp:200: DB::InterpreterInsertQuery::getSampleBlock(DB::ASTInsertQuery const&, std::shared_ptr const&, std::shared_ptr const&, std::shared_ptr, bool, bool) @ 0x000000001492c400 6. /build/src/Interpreters/InterpreterInsertQuery.cpp:838: DB::InterpreterInsertQuery::execute() @ 0x0000000014933ae7 7. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88dc9 8. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 9. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 10. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 11. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 12. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 13. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 14. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 15. ? @ 0x00007fbc6213eac3 16. ? @ 0x00007fbc621d0850 2025.07.28 11:59:55.478898 [ 3970 ] {} test_13.rmt2 (7f9b740d-015c-470e-8cc6-8ba33be0dc63): auto DB::StorageReplicatedMergeTree::processQueueEntry(ReplicatedMergeTreeQueue::SelectedEntryPtr)::(anonymous class)::operator()(LogEntryPtr &) const: Code: 86. DB::HTTPException: Received error from remote server http://146b4357c08d:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Ftest%2F01165%2Ftest_13%2Frmt%2Freplicas%2F1&part=20250728_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.6.10636.altinitytest (altinity build)) '. (RECEIVED_ERROR_FROM_REMOTE_IO_SERVER), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.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 const&, int&&, String const&, unsigned long&&, String const&) @ 0x000000000feda8d9 4. /build/src/IO/HTTPCommon.cpp:104: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x000000000feda6e2 5. /build/src/IO/HTTPCommon.cpp:93: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x000000000feda537 6. /build/src/IO/ReadWriteBufferFromHTTP.cpp:277: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x000000001184a4c4 7. /build/src/IO/ReadWriteBufferFromHTTP.cpp:285: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x000000001184a615 8. /build/src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x000000001184ae59 9. /build/src/IO/ReadWriteBufferFromHTTP.cpp:472: void std::__function::__policy_invoker::__call_impl[abi:se190107]>(std::__function::__policy_storage const*) @ 0x000000001184cedd 10. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001184858b 11. /build/src/IO/ReadWriteBufferFromHTTP.cpp:465: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x000000001184bf0b 12. /build/src/IO/ReadBuffer.h:60: DB::ReadBuffer::next() @ 0x000000000a148c7b 13. /build/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) @ 0x0000000011849fb2 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]>&)>&, 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&) @ 0x0000000011841980 15. /build/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) @ 0x000000001621208e 16. /build/src/Storages/StorageReplicatedMergeTree.cpp:5228: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl[abi:se190107] const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000015f9a5fe 17. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000015ed8bfd 18. /build/src/Storages/StorageReplicatedMergeTree.cpp:2514: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x0000000015ec9aab 19. /build/src/Storages/StorageReplicatedMergeTree.cpp:2349: DB::StorageReplicatedMergeTree::executeLogEntry(DB::ReplicatedMergeTreeLogEntry&) @ 0x0000000015eba91b 20. /build/src/Storages/StorageReplicatedMergeTree.cpp:3876: bool std::__function::__policy_invoker&)>::__call_impl[abi:se190107])::$_1, bool (std::shared_ptr&)>>(std::__function::__policy_storage const*, std::shared_ptr&) @ 0x0000000015f9837e 21. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000165d6fc3 22. /build/src/Storages/StorageReplicatedMergeTree.cpp:3872: DB::StorageReplicatedMergeTree::processQueueEntry(std::shared_ptr) @ 0x0000000015efc18a 23. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001624c1b2 24. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000162f9c70 25. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x00000000162fa55a 26. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc6653 27. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000000fccc4c3 28. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc3d92 29. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fcca080 30. ? @ 0x00007fbc6213eac3 31. ? @ 0x00007fbc621d0850 (version 25.3.6.10636.altinitytest (altinity build)) 2025.07.28 11:59:55.546270 [ 11826 ] {b5cde48b-1496-49f1-b87a-32566dcc4bbc} executeQuery: Code: 16. DB::Exception: No such column versionxyz in table system.zookeeper (6552da84-3d59-4534-92b4-d83c95b890c0). (NO_SUCH_COLUMN_IN_TABLE) (version 25.3.6.10636.altinitytest (altinity build)) (from [::1]:38918) (comment: 02311_system_zookeeper_insert.sql) (query 18, line 37) (in query: insert into system.zookeeper (name, versionxyz) values ), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x000000000a6a1e2b 4. /build/src/Interpreters/InterpreterInsertQuery.cpp:258: DB::InterpreterInsertQuery::getSampleBlockImpl(std::vector> const&, std::shared_ptr const&, std::shared_ptr const&, bool, bool) @ 0x000000001492cf06 5. /build/src/Interpreters/InterpreterInsertQuery.cpp:200: DB::InterpreterInsertQuery::getSampleBlock(DB::ASTInsertQuery const&, std::shared_ptr const&, std::shared_ptr const&, std::shared_ptr, bool, bool) @ 0x000000001492c400 6. /build/src/Interpreters/InterpreterInsertQuery.cpp:838: DB::InterpreterInsertQuery::execute() @ 0x0000000014933ae7 7. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88dc9 8. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 9. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 10. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 11. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 12. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 13. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 14. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 15. ? @ 0x00007fbc6213eac3 16. ? @ 0x00007fbc621d0850 2025.07.28 11:59:55.550194 [ 11826 ] {} TCPHandler: Code: 16. DB::Exception: No such column versionxyz in table system.zookeeper (6552da84-3d59-4534-92b4-d83c95b890c0). (NO_SUCH_COLUMN_IN_TABLE), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x000000000a6a1e2b 4. /build/src/Interpreters/InterpreterInsertQuery.cpp:258: DB::InterpreterInsertQuery::getSampleBlockImpl(std::vector> const&, std::shared_ptr const&, std::shared_ptr const&, bool, bool) @ 0x000000001492cf06 5. /build/src/Interpreters/InterpreterInsertQuery.cpp:200: DB::InterpreterInsertQuery::getSampleBlock(DB::ASTInsertQuery const&, std::shared_ptr const&, std::shared_ptr const&, std::shared_ptr, bool, bool) @ 0x000000001492c400 6. /build/src/Interpreters/InterpreterInsertQuery.cpp:838: DB::InterpreterInsertQuery::execute() @ 0x0000000014933ae7 7. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88dc9 8. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 9. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 10. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 11. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 12. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 13. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 14. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 15. ? @ 0x00007fbc6213eac3 16. ? @ 0x00007fbc621d0850 2025.07.28 11:59:55.551468 [ 5327 ] {} TCPHandler: TCPHandler: Code: 81. DB::Exception: Database test_11 does not exist. Maybe you meant test_1?. (UNKNOWN_DATABASE), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000a06a8eb 4. /build/src/Interpreters/DatabaseCatalog.cpp:535: DB::DatabaseCatalog::assertDatabaseExists(String const&) const @ 0x00000000144f31f6 5. /build/src/Server/TCPHandler.cpp:342: DB::TCPHandler::runImpl() @ 0x00000000168e5a19 6. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 7. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 8. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 9. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 10. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 11. ? @ 0x00007fbc6213eac3 12. ? @ 0x00007fbc621d0850 (version 25.3.6.10636.altinitytest (altinity build)) 2025.07.28 11:59:55.552183 [ 5327 ] {} ServerErrorHandler: Code: 81. DB::Exception: Database test_11 does not exist. Maybe you meant test_1?. (UNKNOWN_DATABASE), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000a06a8eb 4. /build/src/Interpreters/DatabaseCatalog.cpp:535: DB::DatabaseCatalog::assertDatabaseExists(String const&) const @ 0x00000000144f31f6 5. /build/src/Server/TCPHandler.cpp:342: DB::TCPHandler::runImpl() @ 0x00000000168e5a19 6. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 7. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 8. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 9. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 10. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 11. ? @ 0x00007fbc6213eac3 12. ? @ 0x00007fbc621d0850 (version 25.3.6.10636.altinitytest (altinity build)) 2025.07.28 11:59:55.665039 [ 5327 ] {} TCPHandler: TCPHandler: Code: 81. DB::Exception: Database test_11 does not exist. Maybe you meant test_1?. (UNKNOWN_DATABASE), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000a06a8eb 4. /build/src/Interpreters/DatabaseCatalog.cpp:535: DB::DatabaseCatalog::assertDatabaseExists(String const&) const @ 0x00000000144f31f6 5. /build/src/Server/TCPHandler.cpp:342: DB::TCPHandler::runImpl() @ 0x00000000168e5a19 6. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 7. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 8. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 9. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 10. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 11. ? @ 0x00007fbc6213eac3 12. ? @ 0x00007fbc621d0850 (version 25.3.6.10636.altinitytest (altinity build)) 2025.07.28 11:59:55.667109 [ 5327 ] {} ServerErrorHandler: Code: 81. DB::Exception: Database test_11 does not exist. Maybe you meant test_1?. (UNKNOWN_DATABASE), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000a06a8eb 4. /build/src/Interpreters/DatabaseCatalog.cpp:535: DB::DatabaseCatalog::assertDatabaseExists(String const&) const @ 0x00000000144f31f6 5. /build/src/Server/TCPHandler.cpp:342: DB::TCPHandler::runImpl() @ 0x00000000168e5a19 6. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 7. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 8. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 9. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 10. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 11. ? @ 0x00007fbc6213eac3 12. ? @ 0x00007fbc621d0850 (version 25.3.6.10636.altinitytest (altinity build)) 2025.07.28 11:59:55.732540 [ 11826 ] {be40a201-3968-4da1-a90b-f38e866569f3} executeQuery: Code: 36. DB::Exception: Column `name` should not contain '/'. (BAD_ARGUMENTS) (version 25.3.6.10636.altinitytest (altinity build)) (from [::1]:38918) (comment: 02311_system_zookeeper_insert.sql) (query 19, line 38) (in query: insert into system.zookeeper (name, path, value) values ), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000000a074fcb 4. /build/src/Storages/System/StorageSystemZooKeeper.cpp:146: DB::ZooKeeperSink::consume(DB::Chunk&) @ 0x0000000011a8484c 5. /build/src/Processors/Sinks/SinkToStorage.cpp:10: DB::SinkToStorage::onConsume(DB::Chunk) @ 0x0000000016cee093 6. /build/src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: void std::__function::__policy_invoker::__call_impl[abi:se190107]>(std::__function::__policy_storage const*) @ 0x0000000016c0ad89 7. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000016c0abf5 8. /build/src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: DB::ExceptionKeepingTransform::work() @ 0x0000000016c0a6fe 9. /build/src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x00000000169bd00f 10. /build/src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x00000000169b2105 11. /build/src/Processors/Executors/PipelineExecutor.cpp:170: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x00000000169b16a7 12. /build/src/Processors/Executors/PushingPipelineExecutor.cpp:131: DB::PushingPipelineExecutor::finish() @ 0x00000000169c359f 13. /build/src/Server/TCPHandler.cpp:1128: DB::TCPHandler::processInsertQuery(DB::QueryState&) @ 0x00000000168f0d2c 14. /build/src/Server/TCPHandler.cpp:673: DB::TCPHandler::runImpl() @ 0x00000000168e68bc 15. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 16. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 17. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 18. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 19. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 20. ? @ 0x00007fbc6213eac3 21. ? @ 0x00007fbc621d0850 2025.07.28 11:59:55.735470 [ 11826 ] {} TCPHandler: Code: 36. DB::Exception: Column `name` should not contain '/'. (BAD_ARGUMENTS), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000000a074fcb 4. /build/src/Storages/System/StorageSystemZooKeeper.cpp:146: DB::ZooKeeperSink::consume(DB::Chunk&) @ 0x0000000011a8484c 5. /build/src/Processors/Sinks/SinkToStorage.cpp:10: DB::SinkToStorage::onConsume(DB::Chunk) @ 0x0000000016cee093 6. /build/src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: void std::__function::__policy_invoker::__call_impl[abi:se190107]>(std::__function::__policy_storage const*) @ 0x0000000016c0ad89 7. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000016c0abf5 8. /build/src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: DB::ExceptionKeepingTransform::work() @ 0x0000000016c0a6fe 9. /build/src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x00000000169bd00f 10. /build/src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x00000000169b2105 11. /build/src/Processors/Executors/PipelineExecutor.cpp:170: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x00000000169b16a7 12. /build/src/Processors/Executors/PushingPipelineExecutor.cpp:131: DB::PushingPipelineExecutor::finish() @ 0x00000000169c359f 13. /build/src/Server/TCPHandler.cpp:1128: DB::TCPHandler::processInsertQuery(DB::QueryState&) @ 0x00000000168f0d2c 14. /build/src/Server/TCPHandler.cpp:673: DB::TCPHandler::runImpl() @ 0x00000000168e68bc 15. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 16. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 17. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 18. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 19. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 20. ? @ 0x00007fbc6213eac3 21. ? @ 0x00007fbc621d0850 2025.07.28 11:59:55.791339 [ 7625 ] {} TCPHandler: TCPHandler: Code: 81. DB::Exception: Database test_11 does not exist. Maybe you meant test_1?. (UNKNOWN_DATABASE), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000a06a8eb 4. /build/src/Interpreters/DatabaseCatalog.cpp:535: DB::DatabaseCatalog::assertDatabaseExists(String const&) const @ 0x00000000144f31f6 5. /build/src/Server/TCPHandler.cpp:342: DB::TCPHandler::runImpl() @ 0x00000000168e5a19 6. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 7. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 8. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 9. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 10. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 11. ? @ 0x00007fbc6213eac3 12. ? @ 0x00007fbc621d0850 (version 25.3.6.10636.altinitytest (altinity build)) 2025.07.28 11:59:55.791945 [ 7625 ] {} ServerErrorHandler: Code: 81. DB::Exception: Database test_11 does not exist. Maybe you meant test_1?. (UNKNOWN_DATABASE), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000a06a8eb 4. /build/src/Interpreters/DatabaseCatalog.cpp:535: DB::DatabaseCatalog::assertDatabaseExists(String const&) const @ 0x00000000144f31f6 5. /build/src/Server/TCPHandler.cpp:342: DB::TCPHandler::runImpl() @ 0x00000000168e5a19 6. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 7. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 8. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 9. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 10. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 11. ? @ 0x00007fbc6213eac3 12. ? @ 0x00007fbc621d0850 (version 25.3.6.10636.altinitytest (altinity build)) 2025.07.28 11:59:55.907993 [ 7625 ] {} TCPHandler: TCPHandler: Code: 81. DB::Exception: Database test_11 does not exist. Maybe you meant test_1?. (UNKNOWN_DATABASE), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000a06a8eb 4. /build/src/Interpreters/DatabaseCatalog.cpp:535: DB::DatabaseCatalog::assertDatabaseExists(String const&) const @ 0x00000000144f31f6 5. /build/src/Server/TCPHandler.cpp:342: DB::TCPHandler::runImpl() @ 0x00000000168e5a19 6. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 7. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 8. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 9. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 10. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 11. ? @ 0x00007fbc6213eac3 12. ? @ 0x00007fbc621d0850 (version 25.3.6.10636.altinitytest (altinity build)) 2025.07.28 11:59:55.909093 [ 7625 ] {} ServerErrorHandler: Code: 81. DB::Exception: Database test_11 does not exist. Maybe you meant test_1?. (UNKNOWN_DATABASE), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000a06a8eb 4. /build/src/Interpreters/DatabaseCatalog.cpp:535: DB::DatabaseCatalog::assertDatabaseExists(String const&) const @ 0x00000000144f31f6 5. /build/src/Server/TCPHandler.cpp:342: DB::TCPHandler::runImpl() @ 0x00000000168e5a19 6. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 7. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 8. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 9. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 10. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 11. ? @ 0x00007fbc6213eac3 12. ? @ 0x00007fbc621d0850 (version 25.3.6.10636.altinitytest (altinity build)) 2025.07.28 11:59:55.918596 [ 11826 ] {71057b96-470c-4764-b338-c09e03af9aaf} executeQuery: Code: 36. DB::Exception: Column `name` should not contain '/'. (BAD_ARGUMENTS) (version 25.3.6.10636.altinitytest (altinity build)) (from [::1]:38918) (comment: 02311_system_zookeeper_insert.sql) (query 20, line 39) (in query: insert into system.zookeeper (name, path, value) values ), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000000a074fcb 4. /build/src/Storages/System/StorageSystemZooKeeper.cpp:146: DB::ZooKeeperSink::consume(DB::Chunk&) @ 0x0000000011a8484c 5. /build/src/Processors/Sinks/SinkToStorage.cpp:10: DB::SinkToStorage::onConsume(DB::Chunk) @ 0x0000000016cee093 6. /build/src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: void std::__function::__policy_invoker::__call_impl[abi:se190107]>(std::__function::__policy_storage const*) @ 0x0000000016c0ad89 7. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000016c0abf5 8. /build/src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: DB::ExceptionKeepingTransform::work() @ 0x0000000016c0a6fe 9. /build/src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x00000000169bd00f 10. /build/src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x00000000169b2105 11. /build/src/Processors/Executors/PipelineExecutor.cpp:170: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x00000000169b16a7 12. /build/src/Processors/Executors/PushingPipelineExecutor.cpp:131: DB::PushingPipelineExecutor::finish() @ 0x00000000169c359f 13. /build/src/Server/TCPHandler.cpp:1128: DB::TCPHandler::processInsertQuery(DB::QueryState&) @ 0x00000000168f0d2c 14. /build/src/Server/TCPHandler.cpp:673: DB::TCPHandler::runImpl() @ 0x00000000168e68bc 15. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 16. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 17. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 18. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 19. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 20. ? @ 0x00007fbc6213eac3 21. ? @ 0x00007fbc621d0850 2025.07.28 11:59:55.927834 [ 11826 ] {} TCPHandler: Code: 36. DB::Exception: Column `name` should not contain '/'. (BAD_ARGUMENTS), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000000a074fcb 4. /build/src/Storages/System/StorageSystemZooKeeper.cpp:146: DB::ZooKeeperSink::consume(DB::Chunk&) @ 0x0000000011a8484c 5. /build/src/Processors/Sinks/SinkToStorage.cpp:10: DB::SinkToStorage::onConsume(DB::Chunk) @ 0x0000000016cee093 6. /build/src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: void std::__function::__policy_invoker::__call_impl[abi:se190107]>(std::__function::__policy_storage const*) @ 0x0000000016c0ad89 7. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000016c0abf5 8. /build/src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: DB::ExceptionKeepingTransform::work() @ 0x0000000016c0a6fe 9. /build/src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x00000000169bd00f 10. /build/src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x00000000169b2105 11. /build/src/Processors/Executors/PipelineExecutor.cpp:170: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x00000000169b16a7 12. /build/src/Processors/Executors/PushingPipelineExecutor.cpp:131: DB::PushingPipelineExecutor::finish() @ 0x00000000169c359f 13. /build/src/Server/TCPHandler.cpp:1128: DB::TCPHandler::processInsertQuery(DB::QueryState&) @ 0x00000000168f0d2c 14. /build/src/Server/TCPHandler.cpp:673: DB::TCPHandler::runImpl() @ 0x00000000168e68bc 15. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 16. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 17. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 18. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 19. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 20. ? @ 0x00007fbc6213eac3 21. ? @ 0x00007fbc621d0850 2025.07.28 11:59:55.982828 [ 3283 ] {da8f507f-2406-404f-9cdb-0e2773d0dbd0} executeQuery: Code: 582. DB::Exception: There is no projection pp in table. (NO_SUCH_PROJECTION_IN_TABLE) (version 25.3.6.10636.altinitytest (altinity build)) (from [::1]:38822) (comment: 01710_projection_drop_if_exists.sql) (query 3, line 5) (in query: alter table tp drop projection pp;), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x000000000a6a1e2b 4. /build/src/Storages/ProjectionsDescription.cpp:439: DB::ProjectionsDescription::remove(String const&, bool) @ 0x0000000015d4b6fc 5. /build/src/Storages/AlterCommands.cpp:860: DB::AlterCommand::apply(DB::StorageInMemoryMetadata&, std::shared_ptr) const @ 0x0000000015cebf5f 6. /build/src/Storages/AlterCommands.cpp:1263: DB::AlterCommands::apply(DB::StorageInMemoryMetadata&, std::shared_ptr) const @ 0x0000000015cf2c7b 7. /build/src/Storages/MergeTree/MergeTreeData.cpp:3534: DB::MergeTreeData::checkAlterIsPossible(DB::AlterCommands const&, std::shared_ptr) const @ 0x00000000163355eb 8. /build/src/Interpreters/InterpreterAlterQuery.cpp:215: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x00000000148deab3 9. /build/src/Interpreters/InterpreterAlterQuery.cpp:77: DB::InterpreterAlterQuery::execute() @ 0x00000000148dcb0d 10. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88dc9 11. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 12. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 13. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 14. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 15. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 16. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 17. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 18. ? @ 0x00007fbc6213eac3 19. ? @ 0x00007fbc621d0850 2025.07.28 11:59:55.988067 [ 3283 ] {} TCPHandler: Code: 582. DB::Exception: There is no projection pp in table. (NO_SUCH_PROJECTION_IN_TABLE), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x000000000a6a1e2b 4. /build/src/Storages/ProjectionsDescription.cpp:439: DB::ProjectionsDescription::remove(String const&, bool) @ 0x0000000015d4b6fc 5. /build/src/Storages/AlterCommands.cpp:860: DB::AlterCommand::apply(DB::StorageInMemoryMetadata&, std::shared_ptr) const @ 0x0000000015cebf5f 6. /build/src/Storages/AlterCommands.cpp:1263: DB::AlterCommands::apply(DB::StorageInMemoryMetadata&, std::shared_ptr) const @ 0x0000000015cf2c7b 7. /build/src/Storages/MergeTree/MergeTreeData.cpp:3534: DB::MergeTreeData::checkAlterIsPossible(DB::AlterCommands const&, std::shared_ptr) const @ 0x00000000163355eb 8. /build/src/Interpreters/InterpreterAlterQuery.cpp:215: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x00000000148deab3 9. /build/src/Interpreters/InterpreterAlterQuery.cpp:77: DB::InterpreterAlterQuery::execute() @ 0x00000000148dcb0d 10. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88dc9 11. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 12. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 13. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 14. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 15. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 16. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 17. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 18. ? @ 0x00007fbc6213eac3 19. ? @ 0x00007fbc621d0850 2025.07.28 11:59:56.051617 [ 11826 ] {2ecb5f84-fc2d-4e21-b78b-ec0026d3e453} executeQuery: Code: 36. DB::Exception: Column `name` should not be empty. (BAD_ARGUMENTS) (version 25.3.6.10636.altinitytest (altinity build)) (from [::1]:38918) (comment: 02311_system_zookeeper_insert.sql) (query 21, line 40) (in query: insert into system.zookeeper (name, path, value) values ), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000000a074fcb 4. /build/src/Storages/System/StorageSystemZooKeeper.cpp:151: DB::ZooKeeperSink::consume(DB::Chunk&) @ 0x0000000011a847e1 5. /build/src/Processors/Sinks/SinkToStorage.cpp:10: DB::SinkToStorage::onConsume(DB::Chunk) @ 0x0000000016cee093 6. /build/src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: void std::__function::__policy_invoker::__call_impl[abi:se190107]>(std::__function::__policy_storage const*) @ 0x0000000016c0ad89 7. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000016c0abf5 8. /build/src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: DB::ExceptionKeepingTransform::work() @ 0x0000000016c0a6fe 9. /build/src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x00000000169bd00f 10. /build/src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x00000000169b2105 11. /build/src/Processors/Executors/PipelineExecutor.cpp:170: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x00000000169b16a7 12. /build/src/Processors/Executors/PushingPipelineExecutor.cpp:131: DB::PushingPipelineExecutor::finish() @ 0x00000000169c359f 13. /build/src/Server/TCPHandler.cpp:1128: DB::TCPHandler::processInsertQuery(DB::QueryState&) @ 0x00000000168f0d2c 14. /build/src/Server/TCPHandler.cpp:673: DB::TCPHandler::runImpl() @ 0x00000000168e68bc 15. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 16. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 17. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 18. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 19. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 20. ? @ 0x00007fbc6213eac3 21. ? @ 0x00007fbc621d0850 2025.07.28 11:59:56.054655 [ 11826 ] {} TCPHandler: Code: 36. DB::Exception: Column `name` should not be empty. (BAD_ARGUMENTS), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000000a074fcb 4. /build/src/Storages/System/StorageSystemZooKeeper.cpp:151: DB::ZooKeeperSink::consume(DB::Chunk&) @ 0x0000000011a847e1 5. /build/src/Processors/Sinks/SinkToStorage.cpp:10: DB::SinkToStorage::onConsume(DB::Chunk) @ 0x0000000016cee093 6. /build/src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: void std::__function::__policy_invoker::__call_impl[abi:se190107]>(std::__function::__policy_storage const*) @ 0x0000000016c0ad89 7. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000016c0abf5 8. /build/src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: DB::ExceptionKeepingTransform::work() @ 0x0000000016c0a6fe 9. /build/src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x00000000169bd00f 10. /build/src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x00000000169b2105 11. /build/src/Processors/Executors/PipelineExecutor.cpp:170: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x00000000169b16a7 12. /build/src/Processors/Executors/PushingPipelineExecutor.cpp:131: DB::PushingPipelineExecutor::finish() @ 0x00000000169c359f 13. /build/src/Server/TCPHandler.cpp:1128: DB::TCPHandler::processInsertQuery(DB::QueryState&) @ 0x00000000168f0d2c 14. /build/src/Server/TCPHandler.cpp:673: DB::TCPHandler::runImpl() @ 0x00000000168e68bc 15. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 16. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 17. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 18. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 19. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 20. ? @ 0x00007fbc6213eac3 21. ? @ 0x00007fbc621d0850 2025.07.28 11:59:56.057022 [ 7625 ] {} TCPHandler: TCPHandler: Code: 81. DB::Exception: Database test_11 does not exist. Maybe you meant test_1?. (UNKNOWN_DATABASE), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000a06a8eb 4. /build/src/Interpreters/DatabaseCatalog.cpp:535: DB::DatabaseCatalog::assertDatabaseExists(String const&) const @ 0x00000000144f31f6 5. /build/src/Server/TCPHandler.cpp:342: DB::TCPHandler::runImpl() @ 0x00000000168e5a19 6. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 7. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 8. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 9. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 10. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 11. ? @ 0x00007fbc6213eac3 12. ? @ 0x00007fbc621d0850 (version 25.3.6.10636.altinitytest (altinity build)) 2025.07.28 11:59:56.057612 [ 7625 ] {} ServerErrorHandler: Code: 81. DB::Exception: Database test_11 does not exist. Maybe you meant test_1?. (UNKNOWN_DATABASE), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000a06a8eb 4. /build/src/Interpreters/DatabaseCatalog.cpp:535: DB::DatabaseCatalog::assertDatabaseExists(String const&) const @ 0x00000000144f31f6 5. /build/src/Server/TCPHandler.cpp:342: DB::TCPHandler::runImpl() @ 0x00000000168e5a19 6. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 7. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 8. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 9. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 10. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 11. ? @ 0x00007fbc6213eac3 12. ? @ 0x00007fbc621d0850 (version 25.3.6.10636.altinitytest (altinity build)) 2025.07.28 11:59:56.173384 [ 11826 ] {ef4de71e-d557-4143-9059-e3152cc9f373} executeQuery: Code: 36. DB::Exception: Sum of `name` length and `path` length should not exceed PATH_MAX. (BAD_ARGUMENTS) (version 25.3.6.10636.altinitytest (altinity build)) (from [::1]:38918) (comment: 02311_system_zookeeper_insert.sql) (query 22, line 41) (in query: insert into system.zookeeper (name, path, value) values ), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000000a074fcb 4. /build/src/Storages/System/StorageSystemZooKeeper.cpp:161: DB::ZooKeeperSink::consume(DB::Chunk&) @ 0x0000000011a8491f 5. /build/src/Processors/Sinks/SinkToStorage.cpp:10: DB::SinkToStorage::onConsume(DB::Chunk) @ 0x0000000016cee093 6. /build/src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: void std::__function::__policy_invoker::__call_impl[abi:se190107]>(std::__function::__policy_storage const*) @ 0x0000000016c0ad89 7. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000016c0abf5 8. /build/src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: DB::ExceptionKeepingTransform::work() @ 0x0000000016c0a6fe 9. /build/src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x00000000169bd00f 10. /build/src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x00000000169b2105 11. /build/src/Processors/Executors/PipelineExecutor.cpp:170: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x00000000169b16a7 12. /build/src/Processors/Executors/PushingPipelineExecutor.cpp:131: DB::PushingPipelineExecutor::finish() @ 0x00000000169c359f 13. /build/src/Server/TCPHandler.cpp:1128: DB::TCPHandler::processInsertQuery(DB::QueryState&) @ 0x00000000168f0d2c 14. /build/src/Server/TCPHandler.cpp:673: DB::TCPHandler::runImpl() @ 0x00000000168e68bc 15. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 16. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 17. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 18. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 19. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 20. ? @ 0x00007fbc6213eac3 21. ? @ 0x00007fbc621d0850 2025.07.28 11:59:56.188937 [ 3968 ] {} test_13.rmt2 (7f9b740d-015c-470e-8cc6-8ba33be0dc63): auto DB::StorageReplicatedMergeTree::processQueueEntry(ReplicatedMergeTreeQueue::SelectedEntryPtr)::(anonymous class)::operator()(LogEntryPtr &) const: Code: 86. DB::HTTPException: Received error from remote server http://146b4357c08d:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Ftest%2F01165%2Ftest_13%2Frmt%2Freplicas%2F1&part=20250728_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.6.10636.altinitytest (altinity build)) '. (RECEIVED_ERROR_FROM_REMOTE_IO_SERVER), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.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 const&, int&&, String const&, unsigned long&&, String const&) @ 0x000000000feda8d9 4. /build/src/IO/HTTPCommon.cpp:104: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x000000000feda6e2 5. /build/src/IO/HTTPCommon.cpp:93: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x000000000feda537 6. /build/src/IO/ReadWriteBufferFromHTTP.cpp:277: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x000000001184a4c4 7. /build/src/IO/ReadWriteBufferFromHTTP.cpp:285: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x000000001184a615 8. /build/src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x000000001184ae59 9. /build/src/IO/ReadWriteBufferFromHTTP.cpp:472: void std::__function::__policy_invoker::__call_impl[abi:se190107]>(std::__function::__policy_storage const*) @ 0x000000001184cedd 10. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001184858b 11. /build/src/IO/ReadWriteBufferFromHTTP.cpp:465: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x000000001184bf0b 12. /build/src/IO/ReadBuffer.h:60: DB::ReadBuffer::next() @ 0x000000000a148c7b 13. /build/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) @ 0x0000000011849fb2 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]>&)>&, 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&) @ 0x0000000011841980 15. /build/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) @ 0x000000001621208e 16. /build/src/Storages/StorageReplicatedMergeTree.cpp:5228: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl[abi:se190107] const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000015f9a5fe 17. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000015ed8bfd 18. /build/src/Storages/StorageReplicatedMergeTree.cpp:2514: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x0000000015ec9aab 19. /build/src/Storages/StorageReplicatedMergeTree.cpp:2349: DB::StorageReplicatedMergeTree::executeLogEntry(DB::ReplicatedMergeTreeLogEntry&) @ 0x0000000015eba91b 20. /build/src/Storages/StorageReplicatedMergeTree.cpp:3876: bool std::__function::__policy_invoker&)>::__call_impl[abi:se190107])::$_1, bool (std::shared_ptr&)>>(std::__function::__policy_storage const*, std::shared_ptr&) @ 0x0000000015f9837e 21. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000165d6fc3 22. /build/src/Storages/StorageReplicatedMergeTree.cpp:3872: DB::StorageReplicatedMergeTree::processQueueEntry(std::shared_ptr) @ 0x0000000015efc18a 23. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001624c1b2 24. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000162f9c70 25. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x00000000162fa55a 26. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc6653 27. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000000fccc4c3 28. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc3d92 29. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fcca080 30. ? @ 0x00007fbc6213eac3 31. ? @ 0x00007fbc621d0850 (version 25.3.6.10636.altinitytest (altinity build)) 2025.07.28 11:59:56.210783 [ 7625 ] {} TCPHandler: TCPHandler: Code: 81. DB::Exception: Database test_11 does not exist. Maybe you meant test_1?. (UNKNOWN_DATABASE), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000a06a8eb 4. /build/src/Interpreters/DatabaseCatalog.cpp:535: DB::DatabaseCatalog::assertDatabaseExists(String const&) const @ 0x00000000144f31f6 5. /build/src/Server/TCPHandler.cpp:342: DB::TCPHandler::runImpl() @ 0x00000000168e5a19 6. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 7. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 8. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 9. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 10. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 11. ? @ 0x00007fbc6213eac3 12. ? @ 0x00007fbc621d0850 (version 25.3.6.10636.altinitytest (altinity build)) 2025.07.28 11:59:56.211339 [ 7625 ] {} ServerErrorHandler: Code: 81. DB::Exception: Database test_11 does not exist. Maybe you meant test_1?. (UNKNOWN_DATABASE), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000a06a8eb 4. /build/src/Interpreters/DatabaseCatalog.cpp:535: DB::DatabaseCatalog::assertDatabaseExists(String const&) const @ 0x00000000144f31f6 5. /build/src/Server/TCPHandler.cpp:342: DB::TCPHandler::runImpl() @ 0x00000000168e5a19 6. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 7. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 8. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 9. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 10. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 11. ? @ 0x00007fbc6213eac3 12. ? @ 0x00007fbc621d0850 (version 25.3.6.10636.altinitytest (altinity build)) 2025.07.28 11:59:56.272460 [ 11826 ] {} TCPHandler: Code: 36. DB::Exception: Sum of `name` length and `path` length should not exceed PATH_MAX. (BAD_ARGUMENTS), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000000a074fcb 4. /build/src/Storages/System/StorageSystemZooKeeper.cpp:161: DB::ZooKeeperSink::consume(DB::Chunk&) @ 0x0000000011a8491f 5. /build/src/Processors/Sinks/SinkToStorage.cpp:10: DB::SinkToStorage::onConsume(DB::Chunk) @ 0x0000000016cee093 6. /build/src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: void std::__function::__policy_invoker::__call_impl[abi:se190107]>(std::__function::__policy_storage const*) @ 0x0000000016c0ad89 7. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000016c0abf5 8. /build/src/Processors/Transforms/ExceptionKeepingTransform.cpp:151: DB::ExceptionKeepingTransform::work() @ 0x0000000016c0a6fe 9. /build/src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x00000000169bd00f 10. /build/src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x00000000169b2105 11. /build/src/Processors/Executors/PipelineExecutor.cpp:170: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x00000000169b16a7 12. /build/src/Processors/Executors/PushingPipelineExecutor.cpp:131: DB::PushingPipelineExecutor::finish() @ 0x00000000169c359f 13. /build/src/Server/TCPHandler.cpp:1128: DB::TCPHandler::processInsertQuery(DB::QueryState&) @ 0x00000000168f0d2c 14. /build/src/Server/TCPHandler.cpp:673: DB::TCPHandler::runImpl() @ 0x00000000168e68bc 15. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 16. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 17. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 18. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 19. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 20. ? @ 0x00007fbc6213eac3 21. ? @ 0x00007fbc621d0850 2025.07.28 11:59:56.313491 [ 3283 ] {55705bb9-96a5-4e6b-8c3b-9654bc3b1ade} executeQuery: Code: 582. DB::Exception: There is no projection p in table. (NO_SUCH_PROJECTION_IN_TABLE) (version 25.3.6.10636.altinitytest (altinity build)) (from [::1]:38822) (comment: 01710_projection_drop_if_exists.sql) (query 6, line 8) (in query: alter table tp drop projection p;), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x000000000a6a1e2b 4. /build/src/Storages/ProjectionsDescription.cpp:439: DB::ProjectionsDescription::remove(String const&, bool) @ 0x0000000015d4b6fc 5. /build/src/Storages/AlterCommands.cpp:860: DB::AlterCommand::apply(DB::StorageInMemoryMetadata&, std::shared_ptr) const @ 0x0000000015cebf5f 6. /build/src/Storages/AlterCommands.cpp:1263: DB::AlterCommands::apply(DB::StorageInMemoryMetadata&, std::shared_ptr) const @ 0x0000000015cf2c7b 7. /build/src/Storages/MergeTree/MergeTreeData.cpp:3534: DB::MergeTreeData::checkAlterIsPossible(DB::AlterCommands const&, std::shared_ptr) const @ 0x00000000163355eb 8. /build/src/Interpreters/InterpreterAlterQuery.cpp:215: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x00000000148deab3 9. /build/src/Interpreters/InterpreterAlterQuery.cpp:77: DB::InterpreterAlterQuery::execute() @ 0x00000000148dcb0d 10. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88dc9 11. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 12. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 13. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 14. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 15. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 16. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 17. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 18. ? @ 0x00007fbc6213eac3 19. ? @ 0x00007fbc621d0850 2025.07.28 11:59:56.325255 [ 3283 ] {} TCPHandler: Code: 582. DB::Exception: There is no projection p in table. (NO_SUCH_PROJECTION_IN_TABLE), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x000000000a6a1e2b 4. /build/src/Storages/ProjectionsDescription.cpp:439: DB::ProjectionsDescription::remove(String const&, bool) @ 0x0000000015d4b6fc 5. /build/src/Storages/AlterCommands.cpp:860: DB::AlterCommand::apply(DB::StorageInMemoryMetadata&, std::shared_ptr) const @ 0x0000000015cebf5f 6. /build/src/Storages/AlterCommands.cpp:1263: DB::AlterCommands::apply(DB::StorageInMemoryMetadata&, std::shared_ptr) const @ 0x0000000015cf2c7b 7. /build/src/Storages/MergeTree/MergeTreeData.cpp:3534: DB::MergeTreeData::checkAlterIsPossible(DB::AlterCommands const&, std::shared_ptr) const @ 0x00000000163355eb 8. /build/src/Interpreters/InterpreterAlterQuery.cpp:215: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x00000000148deab3 9. /build/src/Interpreters/InterpreterAlterQuery.cpp:77: DB::InterpreterAlterQuery::execute() @ 0x00000000148dcb0d 10. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88dc9 11. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 12. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 13. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 14. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 15. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 16. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 17. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 18. ? @ 0x00007fbc6213eac3 19. ? @ 0x00007fbc621d0850 2025.07.28 11:59:56.616533 [ 3960 ] {} test_13.rmt2 (7f9b740d-015c-470e-8cc6-8ba33be0dc63): auto DB::StorageReplicatedMergeTree::processQueueEntry(ReplicatedMergeTreeQueue::SelectedEntryPtr)::(anonymous class)::operator()(LogEntryPtr &) const: Code: 86. DB::HTTPException: Received error from remote server http://146b4357c08d:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Ftest%2F01165%2Ftest_13%2Frmt%2Freplicas%2F1&part=20250728_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.6.10636.altinitytest (altinity build)) '. (RECEIVED_ERROR_FROM_REMOTE_IO_SERVER), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.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 const&, int&&, String const&, unsigned long&&, String const&) @ 0x000000000feda8d9 4. /build/src/IO/HTTPCommon.cpp:104: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x000000000feda6e2 5. /build/src/IO/HTTPCommon.cpp:93: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x000000000feda537 6. /build/src/IO/ReadWriteBufferFromHTTP.cpp:277: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x000000001184a4c4 7. /build/src/IO/ReadWriteBufferFromHTTP.cpp:285: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x000000001184a615 8. /build/src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x000000001184ae59 9. /build/src/IO/ReadWriteBufferFromHTTP.cpp:472: void std::__function::__policy_invoker::__call_impl[abi:se190107]>(std::__function::__policy_storage const*) @ 0x000000001184cedd 10. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001184858b 11. /build/src/IO/ReadWriteBufferFromHTTP.cpp:465: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x000000001184bf0b 12. /build/src/IO/ReadBuffer.h:60: DB::ReadBuffer::next() @ 0x000000000a148c7b 13. /build/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) @ 0x0000000011849fb2 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]>&)>&, 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&) @ 0x0000000011841980 15. /build/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) @ 0x000000001621208e 16. /build/src/Storages/StorageReplicatedMergeTree.cpp:5228: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl[abi:se190107] const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000015f9a5fe 17. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000015ed8bfd 18. /build/src/Storages/StorageReplicatedMergeTree.cpp:2514: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x0000000015ec9aab 19. /build/src/Storages/StorageReplicatedMergeTree.cpp:2349: DB::StorageReplicatedMergeTree::executeLogEntry(DB::ReplicatedMergeTreeLogEntry&) @ 0x0000000015eba91b 20. /build/src/Storages/StorageReplicatedMergeTree.cpp:3876: bool std::__function::__policy_invoker&)>::__call_impl[abi:se190107])::$_1, bool (std::shared_ptr&)>>(std::__function::__policy_storage const*, std::shared_ptr&) @ 0x0000000015f9837e 21. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000165d6fc3 22. /build/src/Storages/StorageReplicatedMergeTree.cpp:3872: DB::StorageReplicatedMergeTree::processQueueEntry(std::shared_ptr) @ 0x0000000015efc18a 23. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001624c1b2 24. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000162f9c70 25. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x00000000162fa55a 26. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc6653 27. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000000fccc4c3 28. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc3d92 29. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fcca080 30. ? @ 0x00007fbc6213eac3 31. ? @ 0x00007fbc621d0850 (version 25.3.6.10636.altinitytest (altinity build)) 2025.07.28 11:59:57.099787 [ 17270 ] {} TCPHandler: TCPHandler: Code: 81. DB::Exception: Database test_11 does not exist. Maybe you meant test_1?. (UNKNOWN_DATABASE), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000a06a8eb 4. /build/src/Interpreters/DatabaseCatalog.cpp:535: DB::DatabaseCatalog::assertDatabaseExists(String const&) const @ 0x00000000144f31f6 5. /build/src/Server/TCPHandler.cpp:342: DB::TCPHandler::runImpl() @ 0x00000000168e5a19 6. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 7. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 8. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 9. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 10. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 11. ? @ 0x00007fbc6213eac3 12. ? @ 0x00007fbc621d0850 (version 25.3.6.10636.altinitytest (altinity build)) 2025.07.28 11:59:57.107345 [ 17270 ] {} ServerErrorHandler: Code: 81. DB::Exception: Database test_11 does not exist. Maybe you meant test_1?. (UNKNOWN_DATABASE), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000a06a8eb 4. /build/src/Interpreters/DatabaseCatalog.cpp:535: DB::DatabaseCatalog::assertDatabaseExists(String const&) const @ 0x00000000144f31f6 5. /build/src/Server/TCPHandler.cpp:342: DB::TCPHandler::runImpl() @ 0x00000000168e5a19 6. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 7. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 8. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 9. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 10. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 11. ? @ 0x00007fbc6213eac3 12. ? @ 0x00007fbc621d0850 (version 25.3.6.10636.altinitytest (altinity build)) 2025.07.28 11:59:57.229657 [ 3285 ] {} TCPHandler: TCPHandler: Code: 81. DB::Exception: Database test_11 does not exist. Maybe you meant test_1?. (UNKNOWN_DATABASE), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000a06a8eb 4. /build/src/Interpreters/DatabaseCatalog.cpp:535: DB::DatabaseCatalog::assertDatabaseExists(String const&) const @ 0x00000000144f31f6 5. /build/src/Server/TCPHandler.cpp:342: DB::TCPHandler::runImpl() @ 0x00000000168e5a19 6. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 7. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 8. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 9. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 10. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 11. ? @ 0x00007fbc6213eac3 12. ? @ 0x00007fbc621d0850 (version 25.3.6.10636.altinitytest (altinity build)) 2025.07.28 11:59:57.230611 [ 3285 ] {} ServerErrorHandler: Code: 81. DB::Exception: Database test_11 does not exist. Maybe you meant test_1?. (UNKNOWN_DATABASE), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000a06a8eb 4. /build/src/Interpreters/DatabaseCatalog.cpp:535: DB::DatabaseCatalog::assertDatabaseExists(String const&) const @ 0x00000000144f31f6 5. /build/src/Server/TCPHandler.cpp:342: DB::TCPHandler::runImpl() @ 0x00000000168e5a19 6. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 7. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 8. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 9. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 10. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 11. ? @ 0x00007fbc6213eac3 12. ? @ 0x00007fbc621d0850 (version 25.3.6.10636.altinitytest (altinity build)) 2025.07.28 11:59:57.378054 [ 3969 ] {} test_13.rmt2 (7f9b740d-015c-470e-8cc6-8ba33be0dc63): auto DB::StorageReplicatedMergeTree::processQueueEntry(ReplicatedMergeTreeQueue::SelectedEntryPtr)::(anonymous class)::operator()(LogEntryPtr &) const: Code: 86. DB::HTTPException: Received error from remote server http://146b4357c08d:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Ftest%2F01165%2Ftest_13%2Frmt%2Freplicas%2F1&part=20250728_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.6.10636.altinitytest (altinity build)) '. (RECEIVED_ERROR_FROM_REMOTE_IO_SERVER), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.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 const&, int&&, String const&, unsigned long&&, String const&) @ 0x000000000feda8d9 4. /build/src/IO/HTTPCommon.cpp:104: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x000000000feda6e2 5. /build/src/IO/HTTPCommon.cpp:93: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x000000000feda537 6. /build/src/IO/ReadWriteBufferFromHTTP.cpp:277: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x000000001184a4c4 7. /build/src/IO/ReadWriteBufferFromHTTP.cpp:285: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x000000001184a615 8. /build/src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x000000001184ae59 9. /build/src/IO/ReadWriteBufferFromHTTP.cpp:472: void std::__function::__policy_invoker::__call_impl[abi:se190107]>(std::__function::__policy_storage const*) @ 0x000000001184cedd 10. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001184858b 11. /build/src/IO/ReadWriteBufferFromHTTP.cpp:465: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x000000001184bf0b 12. /build/src/IO/ReadBuffer.h:60: DB::ReadBuffer::next() @ 0x000000000a148c7b 13. /build/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) @ 0x0000000011849fb2 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]>&)>&, 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&) @ 0x0000000011841980 15. /build/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) @ 0x000000001621208e 16. /build/src/Storages/StorageReplicatedMergeTree.cpp:5228: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl[abi:se190107] const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000015f9a5fe 17. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000015ed8bfd 18. /build/src/Storages/StorageReplicatedMergeTree.cpp:2514: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x0000000015ec9aab 19. /build/src/Storages/StorageReplicatedMergeTree.cpp:2349: DB::StorageReplicatedMergeTree::executeLogEntry(DB::ReplicatedMergeTreeLogEntry&) @ 0x0000000015eba91b 20. /build/src/Storages/StorageReplicatedMergeTree.cpp:3876: bool std::__function::__policy_invoker&)>::__call_impl[abi:se190107])::$_1, bool (std::shared_ptr&)>>(std::__function::__policy_storage const*, std::shared_ptr&) @ 0x0000000015f9837e 21. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000165d6fc3 22. /build/src/Storages/StorageReplicatedMergeTree.cpp:3872: DB::StorageReplicatedMergeTree::processQueueEntry(std::shared_ptr) @ 0x0000000015efc18a 23. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001624c1b2 24. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000162f9c70 25. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x00000000162fa55a 26. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc6653 27. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000000fccc4c3 28. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc3d92 29. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fcca080 30. ? @ 0x00007fbc6213eac3 31. ? @ 0x00007fbc621d0850 (version 25.3.6.10636.altinitytest (altinity build)) 2025.07.28 11:59:57.417255 [ 4581 ] {} TCPHandler: TCPHandler: Code: 81. DB::Exception: Database test_11 does not exist. Maybe you meant test_1?. (UNKNOWN_DATABASE), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000a06a8eb 4. /build/src/Interpreters/DatabaseCatalog.cpp:535: DB::DatabaseCatalog::assertDatabaseExists(String const&) const @ 0x00000000144f31f6 5. /build/src/Server/TCPHandler.cpp:342: DB::TCPHandler::runImpl() @ 0x00000000168e5a19 6. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 7. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 8. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 9. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 10. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 11. ? @ 0x00007fbc6213eac3 12. ? @ 0x00007fbc621d0850 (version 25.3.6.10636.altinitytest (altinity build)) 2025.07.28 11:59:57.418617 [ 4581 ] {} ServerErrorHandler: Code: 81. DB::Exception: Database test_11 does not exist. Maybe you meant test_1?. (UNKNOWN_DATABASE), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000a06a8eb 4. /build/src/Interpreters/DatabaseCatalog.cpp:535: DB::DatabaseCatalog::assertDatabaseExists(String const&) const @ 0x00000000144f31f6 5. /build/src/Server/TCPHandler.cpp:342: DB::TCPHandler::runImpl() @ 0x00000000168e5a19 6. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 7. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 8. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 9. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 10. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 11. ? @ 0x00007fbc6213eac3 12. ? @ 0x00007fbc621d0850 (version 25.3.6.10636.altinitytest (altinity build)) 2025.07.28 11:59:57.603891 [ 5327 ] {} TCPHandler: TCPHandler: Code: 81. DB::Exception: Database test_11 does not exist. Maybe you meant test_1?. (UNKNOWN_DATABASE), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000a06a8eb 4. /build/src/Interpreters/DatabaseCatalog.cpp:535: DB::DatabaseCatalog::assertDatabaseExists(String const&) const @ 0x00000000144f31f6 5. /build/src/Server/TCPHandler.cpp:342: DB::TCPHandler::runImpl() @ 0x00000000168e5a19 6. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 7. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 8. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 9. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 10. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 11. ? @ 0x00007fbc6213eac3 12. ? @ 0x00007fbc621d0850 (version 25.3.6.10636.altinitytest (altinity build)) 2025.07.28 11:59:57.608906 [ 5327 ] {} ServerErrorHandler: Code: 81. DB::Exception: Database test_11 does not exist. Maybe you meant test_1?. (UNKNOWN_DATABASE), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000a06a8eb 4. /build/src/Interpreters/DatabaseCatalog.cpp:535: DB::DatabaseCatalog::assertDatabaseExists(String const&) const @ 0x00000000144f31f6 5. /build/src/Server/TCPHandler.cpp:342: DB::TCPHandler::runImpl() @ 0x00000000168e5a19 6. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 7. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 8. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 9. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 10. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 11. ? @ 0x00007fbc6213eac3 12. ? @ 0x00007fbc621d0850 (version 25.3.6.10636.altinitytest (altinity build)) 2025.07.28 11:59:57.682672 [ 3967 ] {} test_13.rmt2 (7f9b740d-015c-470e-8cc6-8ba33be0dc63): auto DB::StorageReplicatedMergeTree::processQueueEntry(ReplicatedMergeTreeQueue::SelectedEntryPtr)::(anonymous class)::operator()(LogEntryPtr &) const: Code: 86. DB::HTTPException: Received error from remote server http://146b4357c08d:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Ftest%2F01165%2Ftest_13%2Frmt%2Freplicas%2F1&part=20250728_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.6.10636.altinitytest (altinity build)) '. (RECEIVED_ERROR_FROM_REMOTE_IO_SERVER), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.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 const&, int&&, String const&, unsigned long&&, String const&) @ 0x000000000feda8d9 4. /build/src/IO/HTTPCommon.cpp:104: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x000000000feda6e2 5. /build/src/IO/HTTPCommon.cpp:93: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x000000000feda537 6. /build/src/IO/ReadWriteBufferFromHTTP.cpp:277: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x000000001184a4c4 7. /build/src/IO/ReadWriteBufferFromHTTP.cpp:285: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x000000001184a615 8. /build/src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x000000001184ae59 9. /build/src/IO/ReadWriteBufferFromHTTP.cpp:472: void std::__function::__policy_invoker::__call_impl[abi:se190107]>(std::__function::__policy_storage const*) @ 0x000000001184cedd 10. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001184858b 11. /build/src/IO/ReadWriteBufferFromHTTP.cpp:465: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x000000001184bf0b 12. /build/src/IO/ReadBuffer.h:60: DB::ReadBuffer::next() @ 0x000000000a148c7b 13. /build/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) @ 0x0000000011849fb2 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]>&)>&, 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&) @ 0x0000000011841980 15. /build/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) @ 0x000000001621208e 16. /build/src/Storages/StorageReplicatedMergeTree.cpp:5228: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl[abi:se190107] const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000015f9a5fe 17. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000015ed8bfd 18. /build/src/Storages/StorageReplicatedMergeTree.cpp:2514: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x0000000015ec9aab 19. /build/src/Storages/StorageReplicatedMergeTree.cpp:2349: DB::StorageReplicatedMergeTree::executeLogEntry(DB::ReplicatedMergeTreeLogEntry&) @ 0x0000000015eba91b 20. /build/src/Storages/StorageReplicatedMergeTree.cpp:3876: bool std::__function::__policy_invoker&)>::__call_impl[abi:se190107])::$_1, bool (std::shared_ptr&)>>(std::__function::__policy_storage const*, std::shared_ptr&) @ 0x0000000015f9837e 21. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000165d6fc3 22. /build/src/Storages/StorageReplicatedMergeTree.cpp:3872: DB::StorageReplicatedMergeTree::processQueueEntry(std::shared_ptr) @ 0x0000000015efc18a 23. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001624c1b2 24. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000162f9c70 25. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x00000000162fa55a 26. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc6653 27. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000000fccc4c3 28. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc3d92 29. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fcca080 30. ? @ 0x00007fbc6213eac3 31. ? @ 0x00007fbc621d0850 (version 25.3.6.10636.altinitytest (altinity build)) 2025.07.28 11:59:57.750933 [ 5327 ] {} TCPHandler: TCPHandler: Code: 81. DB::Exception: Database test_11 does not exist. Maybe you meant test_1?. (UNKNOWN_DATABASE), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000a06a8eb 4. /build/src/Interpreters/DatabaseCatalog.cpp:535: DB::DatabaseCatalog::assertDatabaseExists(String const&) const @ 0x00000000144f31f6 5. /build/src/Server/TCPHandler.cpp:342: DB::TCPHandler::runImpl() @ 0x00000000168e5a19 6. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 7. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 8. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 9. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 10. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 11. ? @ 0x00007fbc6213eac3 12. ? @ 0x00007fbc621d0850 (version 25.3.6.10636.altinitytest (altinity build)) 2025.07.28 11:59:57.752003 [ 5327 ] {} ServerErrorHandler: Code: 81. DB::Exception: Database test_11 does not exist. Maybe you meant test_1?. (UNKNOWN_DATABASE), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000a06a8eb 4. /build/src/Interpreters/DatabaseCatalog.cpp:535: DB::DatabaseCatalog::assertDatabaseExists(String const&) const @ 0x00000000144f31f6 5. /build/src/Server/TCPHandler.cpp:342: DB::TCPHandler::runImpl() @ 0x00000000168e5a19 6. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 7. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 8. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 9. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 10. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 11. ? @ 0x00007fbc6213eac3 12. ? @ 0x00007fbc621d0850 (version 25.3.6.10636.altinitytest (altinity build)) 2025.07.28 11:59:58.539927 [ 3965 ] {} test_13.rmt2 (7f9b740d-015c-470e-8cc6-8ba33be0dc63): auto DB::StorageReplicatedMergeTree::processQueueEntry(ReplicatedMergeTreeQueue::SelectedEntryPtr)::(anonymous class)::operator()(LogEntryPtr &) const: Code: 86. DB::HTTPException: Received error from remote server http://146b4357c08d:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Ftest%2F01165%2Ftest_13%2Frmt%2Freplicas%2F1&part=20250728_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.6.10636.altinitytest (altinity build)) '. (RECEIVED_ERROR_FROM_REMOTE_IO_SERVER), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.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 const&, int&&, String const&, unsigned long&&, String const&) @ 0x000000000feda8d9 4. /build/src/IO/HTTPCommon.cpp:104: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x000000000feda6e2 5. /build/src/IO/HTTPCommon.cpp:93: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x000000000feda537 6. /build/src/IO/ReadWriteBufferFromHTTP.cpp:277: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x000000001184a4c4 7. /build/src/IO/ReadWriteBufferFromHTTP.cpp:285: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x000000001184a615 8. /build/src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x000000001184ae59 9. /build/src/IO/ReadWriteBufferFromHTTP.cpp:472: void std::__function::__policy_invoker::__call_impl[abi:se190107]>(std::__function::__policy_storage const*) @ 0x000000001184cedd 10. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001184858b 11. /build/src/IO/ReadWriteBufferFromHTTP.cpp:465: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x000000001184bf0b 12. /build/src/IO/ReadBuffer.h:60: DB::ReadBuffer::next() @ 0x000000000a148c7b 13. /build/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) @ 0x0000000011849fb2 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]>&)>&, 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&) @ 0x0000000011841980 15. /build/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) @ 0x000000001621208e 16. /build/src/Storages/StorageReplicatedMergeTree.cpp:5228: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl[abi:se190107] const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000015f9a5fe 17. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000015ed8bfd 18. /build/src/Storages/StorageReplicatedMergeTree.cpp:2514: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x0000000015ec9aab 19. /build/src/Storages/StorageReplicatedMergeTree.cpp:2349: DB::StorageReplicatedMergeTree::executeLogEntry(DB::ReplicatedMergeTreeLogEntry&) @ 0x0000000015eba91b 20. /build/src/Storages/StorageReplicatedMergeTree.cpp:3876: bool std::__function::__policy_invoker&)>::__call_impl[abi:se190107])::$_1, bool (std::shared_ptr&)>>(std::__function::__policy_storage const*, std::shared_ptr&) @ 0x0000000015f9837e 21. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000165d6fc3 22. /build/src/Storages/StorageReplicatedMergeTree.cpp:3872: DB::StorageReplicatedMergeTree::processQueueEntry(std::shared_ptr) @ 0x0000000015efc18a 23. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001624c1b2 24. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000162f9c70 25. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x00000000162fa55a 26. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc6653 27. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000000fccc4c3 28. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc3d92 29. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fcca080 30. ? @ 0x00007fbc6213eac3 31. ? @ 0x00007fbc621d0850 (version 25.3.6.10636.altinitytest (altinity build)) 2025.07.28 11:59:58.582476 [ 5825 ] {41537f3f-66f2-45bf-b311-780763c6ae6a} executeQuery: Code: 439. DB::Exception: Cannot schedule a task: failed to start the thread (threads=1, jobs=1). (CANNOT_SCHEDULE_TASK) (version 25.3.6.10636.altinitytest (altinity build)) (from [::1]:39194) (comment: 00091_union_race_conditions_2.sh) (query 26, line 26) (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. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000fccaeeb 4. /build/src/Common/ThreadPool.cpp:275: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000fccc813 5. /build/src/Common/ThreadPool.cpp:308: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fcc8286 6. /build/src/Common/ThreadPool.cpp:494: ThreadPoolImpl>::scheduleOrThrowOnError(std::function, Priority) @ 0x000000000fcc7a0e 7. /build/src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::spawnThreadsImpl() @ 0x00000000169b2c0c 8. /build/src/Processors/Executors/PipelineExecutor.cpp:394: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x00000000169b0ba7 9. /build/src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x00000000169b03f4 10. /build/src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:se190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169bfeab 11. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc3d92 12. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fcca080 13. ? @ 0x00007fbc6213eac3 14. ? @ 0x00007fbc621d0850 2025.07.28 11:59:58.608581 [ 5825 ] {} 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. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000fccaeeb 4. /build/src/Common/ThreadPool.cpp:275: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000fccc813 5. /build/src/Common/ThreadPool.cpp:308: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fcc8286 6. /build/src/Common/ThreadPool.cpp:494: ThreadPoolImpl>::scheduleOrThrowOnError(std::function, Priority) @ 0x000000000fcc7a0e 7. /build/src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::spawnThreadsImpl() @ 0x00000000169b2c0c 8. /build/src/Processors/Executors/PipelineExecutor.cpp:394: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x00000000169b0ba7 9. /build/src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x00000000169b03f4 10. /build/src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:se190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169bfeab 11. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc3d92 12. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fcca080 13. ? @ 0x00007fbc6213eac3 14. ? @ 0x00007fbc621d0850 Job's origin stack trace: 0. /build/src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000000fc33b84 1. /build/src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000000fcc2ea7 2. /build/src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fcc535c 3. /build/src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000000fcc584d 4. /build/src/Common/ThreadPool.h:279: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x00000000169bf193 5. /build/src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x00000000169bf518 6. /build/src/Server/TCPHandler.cpp:1237: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x00000000168f1525 7. /build/src/Server/TCPHandler.cpp:678: DB::TCPHandler::runImpl() @ 0x00000000168e68e5 8. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 9. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 10. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 11. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 12. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 13. ? @ 0x00007fbc6213eac3 14. ? @ 0x00007fbc621d0850 2025.07.28 11:59:58.656682 [ 5327 ] {} TCPHandler: TCPHandler: Code: 81. DB::Exception: Database test_11 does not exist. Maybe you meant test_1?. (UNKNOWN_DATABASE), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000a06a8eb 4. /build/src/Interpreters/DatabaseCatalog.cpp:535: DB::DatabaseCatalog::assertDatabaseExists(String const&) const @ 0x00000000144f31f6 5. /build/src/Server/TCPHandler.cpp:342: DB::TCPHandler::runImpl() @ 0x00000000168e5a19 6. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 7. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 8. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 9. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 10. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 11. ? @ 0x00007fbc6213eac3 12. ? @ 0x00007fbc621d0850 (version 25.3.6.10636.altinitytest (altinity build)) 2025.07.28 11:59:58.657346 [ 5327 ] {} ServerErrorHandler: Code: 81. DB::Exception: Database test_11 does not exist. Maybe you meant test_1?. (UNKNOWN_DATABASE), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000a06a8eb 4. /build/src/Interpreters/DatabaseCatalog.cpp:535: DB::DatabaseCatalog::assertDatabaseExists(String const&) const @ 0x00000000144f31f6 5. /build/src/Server/TCPHandler.cpp:342: DB::TCPHandler::runImpl() @ 0x00000000168e5a19 6. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 7. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 8. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 9. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 10. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 11. ? @ 0x00007fbc6213eac3 12. ? @ 0x00007fbc621d0850 (version 25.3.6.10636.altinitytest (altinity build)) 2025.07.28 11:59:58.790029 [ 3287 ] {} POSTGRESQL-Session-517dabe5-4a8d-4b6a-9ced-28f168ba9c37: 517dabe5-4a8d-4b6a-9ced-28f168ba9c37 Authentication failed with error: There is no user `postgresql_user` in user directories 2025.07.28 11:59:58.791747 [ 3287 ] {} PostgreSQLHandler: DB::Exception: There is no user `postgresql_user` in user directories 2025.07.28 11:59:58.803979 [ 17208 ] {} POSTGRESQL-Session-b924cb5d-0963-4750-91b1-4c9c820bae62: b924cb5d-0963-4750-91b1-4c9c820bae62 Authentication failed with error: There is no user `postgresql_user` in user directories 2025.07.28 11:59:58.804641 [ 17208 ] {} PostgreSQLHandler: DB::Exception: There is no user `postgresql_user` in user directories 2025.07.28 11:59:58.959671 [ 17557 ] {} TCPHandler: TCPHandler: Code: 81. DB::Exception: Database test_11 does not exist. Maybe you meant test_1?. (UNKNOWN_DATABASE), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000a06a8eb 4. /build/src/Interpreters/DatabaseCatalog.cpp:535: DB::DatabaseCatalog::assertDatabaseExists(String const&) const @ 0x00000000144f31f6 5. /build/src/Server/TCPHandler.cpp:342: DB::TCPHandler::runImpl() @ 0x00000000168e5a19 6. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 7. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 8. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 9. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 10. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 11. ? @ 0x00007fbc6213eac3 12. ? @ 0x00007fbc621d0850 (version 25.3.6.10636.altinitytest (altinity build)) 2025.07.28 11:59:58.960302 [ 17557 ] {} ServerErrorHandler: Code: 81. DB::Exception: Database test_11 does not exist. Maybe you meant test_1?. (UNKNOWN_DATABASE), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000a06a8eb 4. /build/src/Interpreters/DatabaseCatalog.cpp:535: DB::DatabaseCatalog::assertDatabaseExists(String const&) const @ 0x00000000144f31f6 5. /build/src/Server/TCPHandler.cpp:342: DB::TCPHandler::runImpl() @ 0x00000000168e5a19 6. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 7. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 8. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 9. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 10. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 11. ? @ 0x00007fbc6213eac3 12. ? @ 0x00007fbc621d0850 (version 25.3.6.10636.altinitytest (altinity build)) 2025.07.28 11:59:59.071330 [ 17557 ] {} TCPHandler: TCPHandler: Code: 81. DB::Exception: Database test_11 does not exist. Maybe you meant test_1?. (UNKNOWN_DATABASE), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000a06a8eb 4. /build/src/Interpreters/DatabaseCatalog.cpp:535: DB::DatabaseCatalog::assertDatabaseExists(String const&) const @ 0x00000000144f31f6 5. /build/src/Server/TCPHandler.cpp:342: DB::TCPHandler::runImpl() @ 0x00000000168e5a19 6. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 7. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 8. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 9. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 10. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 11. ? @ 0x00007fbc6213eac3 12. ? @ 0x00007fbc621d0850 (version 25.3.6.10636.altinitytest (altinity build)) 2025.07.28 11:59:59.071852 [ 17557 ] {} ServerErrorHandler: Code: 81. DB::Exception: Database test_11 does not exist. Maybe you meant test_1?. (UNKNOWN_DATABASE), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000a06a8eb 4. /build/src/Interpreters/DatabaseCatalog.cpp:535: DB::DatabaseCatalog::assertDatabaseExists(String const&) const @ 0x00000000144f31f6 5. /build/src/Server/TCPHandler.cpp:342: DB::TCPHandler::runImpl() @ 0x00000000168e5a19 6. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 7. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 8. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 9. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 10. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 11. ? @ 0x00007fbc6213eac3 12. ? @ 0x00007fbc621d0850 (version 25.3.6.10636.altinitytest (altinity build)) 2025.07.28 11:59:59.352146 [ 3962 ] {} test_13.rmt2 (7f9b740d-015c-470e-8cc6-8ba33be0dc63): auto DB::StorageReplicatedMergeTree::processQueueEntry(ReplicatedMergeTreeQueue::SelectedEntryPtr)::(anonymous class)::operator()(LogEntryPtr &) const: Code: 86. DB::HTTPException: Received error from remote server http://146b4357c08d:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Ftest%2F01165%2Ftest_13%2Frmt%2Freplicas%2F1&part=20250728_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.6.10636.altinitytest (altinity build)) '. (RECEIVED_ERROR_FROM_REMOTE_IO_SERVER), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.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 const&, int&&, String const&, unsigned long&&, String const&) @ 0x000000000feda8d9 4. /build/src/IO/HTTPCommon.cpp:104: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x000000000feda6e2 5. /build/src/IO/HTTPCommon.cpp:93: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x000000000feda537 6. /build/src/IO/ReadWriteBufferFromHTTP.cpp:277: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x000000001184a4c4 7. /build/src/IO/ReadWriteBufferFromHTTP.cpp:285: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x000000001184a615 8. /build/src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x000000001184ae59 9. /build/src/IO/ReadWriteBufferFromHTTP.cpp:472: void std::__function::__policy_invoker::__call_impl[abi:se190107]>(std::__function::__policy_storage const*) @ 0x000000001184cedd 10. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001184858b 11. /build/src/IO/ReadWriteBufferFromHTTP.cpp:465: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x000000001184bf0b 12. /build/src/IO/ReadBuffer.h:60: DB::ReadBuffer::next() @ 0x000000000a148c7b 13. /build/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) @ 0x0000000011849fb2 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]>&)>&, 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&) @ 0x0000000011841980 15. /build/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) @ 0x000000001621208e 16. /build/src/Storages/StorageReplicatedMergeTree.cpp:5228: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl[abi:se190107] const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000015f9a5fe 17. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000015ed8bfd 18. /build/src/Storages/StorageReplicatedMergeTree.cpp:2514: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x0000000015ec9aab 19. /build/src/Storages/StorageReplicatedMergeTree.cpp:2349: DB::StorageReplicatedMergeTree::executeLogEntry(DB::ReplicatedMergeTreeLogEntry&) @ 0x0000000015eba91b 20. /build/src/Storages/StorageReplicatedMergeTree.cpp:3876: bool std::__function::__policy_invoker&)>::__call_impl[abi:se190107])::$_1, bool (std::shared_ptr&)>>(std::__function::__policy_storage const*, std::shared_ptr&) @ 0x0000000015f9837e 21. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000165d6fc3 22. /build/src/Storages/StorageReplicatedMergeTree.cpp:3872: DB::StorageReplicatedMergeTree::processQueueEntry(std::shared_ptr) @ 0x0000000015efc18a 23. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001624c1b2 24. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000162f9c70 25. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x00000000162fa55a 26. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc6653 27. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000000fccc4c3 28. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc3d92 29. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fcca080 30. ? @ 0x00007fbc6213eac3 31. ? @ 0x00007fbc621d0850 (version 25.3.6.10636.altinitytest (altinity build)) 2025.07.28 11:59:59.689242 [ 3964 ] {} test_13.rmt2 (7f9b740d-015c-470e-8cc6-8ba33be0dc63): auto DB::StorageReplicatedMergeTree::processQueueEntry(ReplicatedMergeTreeQueue::SelectedEntryPtr)::(anonymous class)::operator()(LogEntryPtr &) const: Code: 86. DB::HTTPException: Received error from remote server http://146b4357c08d:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Ftest%2F01165%2Ftest_13%2Frmt%2Freplicas%2F1&part=20250728_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.6.10636.altinitytest (altinity build)) '. (RECEIVED_ERROR_FROM_REMOTE_IO_SERVER), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.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 const&, int&&, String const&, unsigned long&&, String const&) @ 0x000000000feda8d9 4. /build/src/IO/HTTPCommon.cpp:104: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x000000000feda6e2 5. /build/src/IO/HTTPCommon.cpp:93: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x000000000feda537 6. /build/src/IO/ReadWriteBufferFromHTTP.cpp:277: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x000000001184a4c4 7. /build/src/IO/ReadWriteBufferFromHTTP.cpp:285: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x000000001184a615 8. /build/src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x000000001184ae59 9. /build/src/IO/ReadWriteBufferFromHTTP.cpp:472: void std::__function::__policy_invoker::__call_impl[abi:se190107]>(std::__function::__policy_storage const*) @ 0x000000001184cedd 10. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001184858b 11. /build/src/IO/ReadWriteBufferFromHTTP.cpp:465: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x000000001184bf0b 12. /build/src/IO/ReadBuffer.h:60: DB::ReadBuffer::next() @ 0x000000000a148c7b 13. /build/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) @ 0x0000000011849fb2 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]>&)>&, 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&) @ 0x0000000011841980 15. /build/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) @ 0x000000001621208e 16. /build/src/Storages/StorageReplicatedMergeTree.cpp:5228: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl[abi:se190107] const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000015f9a5fe 17. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000015ed8bfd 18. /build/src/Storages/StorageReplicatedMergeTree.cpp:2514: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x0000000015ec9aab 19. /build/src/Storages/StorageReplicatedMergeTree.cpp:2349: DB::StorageReplicatedMergeTree::executeLogEntry(DB::ReplicatedMergeTreeLogEntry&) @ 0x0000000015eba91b 20. /build/src/Storages/StorageReplicatedMergeTree.cpp:3876: bool std::__function::__policy_invoker&)>::__call_impl[abi:se190107])::$_1, bool (std::shared_ptr&)>>(std::__function::__policy_storage const*, std::shared_ptr&) @ 0x0000000015f9837e 21. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000165d6fc3 22. /build/src/Storages/StorageReplicatedMergeTree.cpp:3872: DB::StorageReplicatedMergeTree::processQueueEntry(std::shared_ptr) @ 0x0000000015efc18a 23. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001624c1b2 24. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000162f9c70 25. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x00000000162fa55a 26. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc6653 27. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000000fccc4c3 28. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc3d92 29. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fcca080 30. ? @ 0x00007fbc6213eac3 31. ? @ 0x00007fbc621d0850 (version 25.3.6.10636.altinitytest (altinity build)) 2025.07.28 11:59:59.790777 [ 17191 ] {} TCPHandler: TCPHandler: Code: 81. DB::Exception: Database test_11 does not exist. Maybe you meant test_1?. (UNKNOWN_DATABASE), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000a06a8eb 4. /build/src/Interpreters/DatabaseCatalog.cpp:535: DB::DatabaseCatalog::assertDatabaseExists(String const&) const @ 0x00000000144f31f6 5. /build/src/Server/TCPHandler.cpp:342: DB::TCPHandler::runImpl() @ 0x00000000168e5a19 6. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 7. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 8. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 9. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 10. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 11. ? @ 0x00007fbc6213eac3 12. ? @ 0x00007fbc621d0850 (version 25.3.6.10636.altinitytest (altinity build)) 2025.07.28 11:59:59.791674 [ 17191 ] {} ServerErrorHandler: Code: 81. DB::Exception: Database test_11 does not exist. Maybe you meant test_1?. (UNKNOWN_DATABASE), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000a06a8eb 4. /build/src/Interpreters/DatabaseCatalog.cpp:535: DB::DatabaseCatalog::assertDatabaseExists(String const&) const @ 0x00000000144f31f6 5. /build/src/Server/TCPHandler.cpp:342: DB::TCPHandler::runImpl() @ 0x00000000168e5a19 6. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 7. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 8. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 9. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 10. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 11. ? @ 0x00007fbc6213eac3 12. ? @ 0x00007fbc621d0850 (version 25.3.6.10636.altinitytest (altinity build)) 2025.07.28 11:59:59.900740 [ 17191 ] {} TCPHandler: TCPHandler: Code: 81. DB::Exception: Database test_11 does not exist. Maybe you meant test_1?. (UNKNOWN_DATABASE), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000a06a8eb 4. /build/src/Interpreters/DatabaseCatalog.cpp:535: DB::DatabaseCatalog::assertDatabaseExists(String const&) const @ 0x00000000144f31f6 5. /build/src/Server/TCPHandler.cpp:342: DB::TCPHandler::runImpl() @ 0x00000000168e5a19 6. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 7. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 8. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 9. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 10. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 11. ? @ 0x00007fbc6213eac3 12. ? @ 0x00007fbc621d0850 (version 25.3.6.10636.altinitytest (altinity build)) 2025.07.28 11:59:59.901547 [ 17191 ] {} ServerErrorHandler: Code: 81. DB::Exception: Database test_11 does not exist. Maybe you meant test_1?. (UNKNOWN_DATABASE), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000a06a8eb 4. /build/src/Interpreters/DatabaseCatalog.cpp:535: DB::DatabaseCatalog::assertDatabaseExists(String const&) const @ 0x00000000144f31f6 5. /build/src/Server/TCPHandler.cpp:342: DB::TCPHandler::runImpl() @ 0x00000000168e5a19 6. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 7. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 8. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 9. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 10. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 11. ? @ 0x00007fbc6213eac3 12. ? @ 0x00007fbc621d0850 (version 25.3.6.10636.altinitytest (altinity build)) 2025.07.28 12:00:00.007868 [ 17207 ] {} TCPHandler: TCPHandler: Code: 81. DB::Exception: Database test_11 does not exist. Maybe you meant test_1?. (UNKNOWN_DATABASE), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000a06a8eb 4. /build/src/Interpreters/DatabaseCatalog.cpp:535: DB::DatabaseCatalog::assertDatabaseExists(String const&) const @ 0x00000000144f31f6 5. /build/src/Server/TCPHandler.cpp:342: DB::TCPHandler::runImpl() @ 0x00000000168e5a19 6. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 7. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 8. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 9. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 10. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 11. ? @ 0x00007fbc6213eac3 12. ? @ 0x00007fbc621d0850 (version 25.3.6.10636.altinitytest (altinity build)) 2025.07.28 12:00:00.008713 [ 17207 ] {} ServerErrorHandler: Code: 81. DB::Exception: Database test_11 does not exist. Maybe you meant test_1?. (UNKNOWN_DATABASE), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000a06a8eb 4. /build/src/Interpreters/DatabaseCatalog.cpp:535: DB::DatabaseCatalog::assertDatabaseExists(String const&) const @ 0x00000000144f31f6 5. /build/src/Server/TCPHandler.cpp:342: DB::TCPHandler::runImpl() @ 0x00000000168e5a19 6. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 7. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 8. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 9. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 10. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 11. ? @ 0x00007fbc6213eac3 12. ? @ 0x00007fbc621d0850 (version 25.3.6.10636.altinitytest (altinity build)) 2025.07.28 12:00:00.131769 [ 17207 ] {} TCPHandler: TCPHandler: Code: 81. DB::Exception: Database test_11 does not exist. Maybe you meant test_1?. (UNKNOWN_DATABASE), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000a06a8eb 4. /build/src/Interpreters/DatabaseCatalog.cpp:535: DB::DatabaseCatalog::assertDatabaseExists(String const&) const @ 0x00000000144f31f6 5. /build/src/Server/TCPHandler.cpp:342: DB::TCPHandler::runImpl() @ 0x00000000168e5a19 6. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 7. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 8. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 9. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 10. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 11. ? @ 0x00007fbc6213eac3 12. ? @ 0x00007fbc621d0850 (version 25.3.6.10636.altinitytest (altinity build)) 2025.07.28 12:00:00.134096 [ 17207 ] {} ServerErrorHandler: Code: 81. DB::Exception: Database test_11 does not exist. Maybe you meant test_1?. (UNKNOWN_DATABASE), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000a06a8eb 4. /build/src/Interpreters/DatabaseCatalog.cpp:535: DB::DatabaseCatalog::assertDatabaseExists(String const&) const @ 0x00000000144f31f6 5. /build/src/Server/TCPHandler.cpp:342: DB::TCPHandler::runImpl() @ 0x00000000168e5a19 6. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 7. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 8. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 9. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 10. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 11. ? @ 0x00007fbc6213eac3 12. ? @ 0x00007fbc621d0850 (version 25.3.6.10636.altinitytest (altinity build)) 2025.07.28 12:00:00.245298 [ 17191 ] {} TCPHandler: TCPHandler: Code: 81. DB::Exception: Database test_11 does not exist. Maybe you meant test_1?. (UNKNOWN_DATABASE), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000a06a8eb 4. /build/src/Interpreters/DatabaseCatalog.cpp:535: DB::DatabaseCatalog::assertDatabaseExists(String const&) const @ 0x00000000144f31f6 5. /build/src/Server/TCPHandler.cpp:342: DB::TCPHandler::runImpl() @ 0x00000000168e5a19 6. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 7. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 8. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 9. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 10. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 11. ? @ 0x00007fbc6213eac3 12. ? @ 0x00007fbc621d0850 (version 25.3.6.10636.altinitytest (altinity build)) 2025.07.28 12:00:00.250471 [ 17191 ] {} ServerErrorHandler: Code: 81. DB::Exception: Database test_11 does not exist. Maybe you meant test_1?. (UNKNOWN_DATABASE), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000a06a8eb 4. /build/src/Interpreters/DatabaseCatalog.cpp:535: DB::DatabaseCatalog::assertDatabaseExists(String const&) const @ 0x00000000144f31f6 5. /build/src/Server/TCPHandler.cpp:342: DB::TCPHandler::runImpl() @ 0x00000000168e5a19 6. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 7. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 8. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 9. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 10. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 11. ? @ 0x00007fbc6213eac3 12. ? @ 0x00007fbc621d0850 (version 25.3.6.10636.altinitytest (altinity build)) 2025.07.28 12:00:00.357180 [ 17191 ] {} TCPHandler: TCPHandler: Code: 81. DB::Exception: Database test_11 does not exist. Maybe you meant test_1?. (UNKNOWN_DATABASE), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000a06a8eb 4. /build/src/Interpreters/DatabaseCatalog.cpp:535: DB::DatabaseCatalog::assertDatabaseExists(String const&) const @ 0x00000000144f31f6 5. /build/src/Server/TCPHandler.cpp:342: DB::TCPHandler::runImpl() @ 0x00000000168e5a19 6. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 7. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 8. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 9. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 10. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 11. ? @ 0x00007fbc6213eac3 12. ? @ 0x00007fbc621d0850 (version 25.3.6.10636.altinitytest (altinity build)) 2025.07.28 12:00:00.357953 [ 17191 ] {} ServerErrorHandler: Code: 81. DB::Exception: Database test_11 does not exist. Maybe you meant test_1?. (UNKNOWN_DATABASE), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000a06a8eb 4. /build/src/Interpreters/DatabaseCatalog.cpp:535: DB::DatabaseCatalog::assertDatabaseExists(String const&) const @ 0x00000000144f31f6 5. /build/src/Server/TCPHandler.cpp:342: DB::TCPHandler::runImpl() @ 0x00000000168e5a19 6. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 7. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 8. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 9. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 10. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 11. ? @ 0x00007fbc6213eac3 12. ? @ 0x00007fbc621d0850 (version 25.3.6.10636.altinitytest (altinity build)) 2025.07.28 12:00:00.393378 [ 4260 ] {8c99e8b4-ea57-4f18-b88c-99ce49059075} AsynchronousInsertQueue: Failed parsing for query 'INSERT INTO test_5.t_json_async_insert (data) FORMAT JSONAsObject' with query id dffceeb8-9ed3-4fbc-a698-28c9917384af. DB::Exception: Cannot parse JSON object here: {"aaa"}: (at row 1) 2025.07.28 12:00:00.426982 [ 17557 ] {dffceeb8-9ed3-4fbc-a698-28c9917384af} executeQuery: Code: 117. DB::Exception: Cannot parse JSON object here: {"aaa"}: (at row 1) : While executing WaitForAsyncInsert. (INCORRECT_DATA) (version 25.3.6.10636.altinitytest (altinity build)) (from [::1]:39132) (comment: 02421_new_type_json_async_insert.sh) (query 1, line 1) (in query: INSERT INTO t_json_async_insert FORMAT JSONAsObject ), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x000000000c25bc4b 4. /build/src/DataTypes/Serializations/SerializationJSON.cpp:299: DB::SerializationJSON::deserializeObject(DB::IColumn&, std::basic_string_view>, DB::FormatSettings const&) const @ 0x0000000013cbaf0d 5. /build/src/DataTypes/Serializations/SerializationJSON.cpp:393: DB::SerializationJSON::deserializeTextJSON(DB::IColumn&, DB::ReadBuffer&, DB::FormatSettings const&) const @ 0x0000000013cbabe6 6. /build/src/Processors/Formats/Impl/JSONAsStringRowInputFormat.cpp:52: DB::JSONAsRowInputFormat::readRow(std::vector::mutable_ptr, std::allocator::mutable_ptr>>&, DB::RowReadExtension&) @ 0x0000000016ac0869 7. /build/src/Processors/Formats/IRowInputFormat.cpp:143: DB::IRowInputFormat::read() @ 0x0000000016a1fc72 8. /build/src/Processors/Formats/IInputFormat.cpp:19: DB::IInputFormat::generate() @ 0x00000000169c5536 9. /build/src/Processors/ISource.cpp:139: DB::ISource::tryGenerate() @ 0x00000000169a24fa 10. /build/src/Processors/ISource.cpp:108: DB::ISource::work() @ 0x00000000169a21e7 11. /build/src/Processors/Executors/StreamingFormatExecutor.cpp:77: DB::StreamingFormatExecutor::execute() @ 0x00000000169c44ca 12. /build/src/Processors/Executors/StreamingFormatExecutor.cpp:58: DB::StreamingFormatExecutor::execute(DB::ReadBuffer&) @ 0x00000000169c431c 13. /build/src/Interpreters/AsynchronousInsertQueue.cpp:1085: DB::AsynchronousInsertQueue::processData(DB::AsynchronousInsertQueue::InsertQuery, std::unique_ptr>, std::shared_ptr, DB::AsynchronousInsertQueue::QueueShardFlushTimeHistory&) @ 0x00000000143e3843 14. /build/src/Interpreters/AsynchronousInsertQueue.cpp:319: void std::__function::__policy_invoker::__call_impl[abi:se190107]>, std::shared_ptr, unsigned long)::$_0, void ()>>(std::__function::__policy_storage const*) @ 0x00000000143e6d04 15. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc6653 16. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000000fccc4c3 17. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc3d92 18. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fcca080 19. ? @ 0x00007fbc6213eac3 20. ? @ 0x00007fbc621d0850 2025.07.28 12:00:00.439527 [ 17557 ] {} TCPHandler: Code: 117. DB::Exception: Cannot parse JSON object here: {"aaa"}: (at row 1) : While executing WaitForAsyncInsert. (INCORRECT_DATA), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x000000000c25bc4b 4. /build/src/DataTypes/Serializations/SerializationJSON.cpp:299: DB::SerializationJSON::deserializeObject(DB::IColumn&, std::basic_string_view>, DB::FormatSettings const&) const @ 0x0000000013cbaf0d 5. /build/src/DataTypes/Serializations/SerializationJSON.cpp:393: DB::SerializationJSON::deserializeTextJSON(DB::IColumn&, DB::ReadBuffer&, DB::FormatSettings const&) const @ 0x0000000013cbabe6 6. /build/src/Processors/Formats/Impl/JSONAsStringRowInputFormat.cpp:52: DB::JSONAsRowInputFormat::readRow(std::vector::mutable_ptr, std::allocator::mutable_ptr>>&, DB::RowReadExtension&) @ 0x0000000016ac0869 7. /build/src/Processors/Formats/IRowInputFormat.cpp:143: DB::IRowInputFormat::read() @ 0x0000000016a1fc72 8. /build/src/Processors/Formats/IInputFormat.cpp:19: DB::IInputFormat::generate() @ 0x00000000169c5536 9. /build/src/Processors/ISource.cpp:139: DB::ISource::tryGenerate() @ 0x00000000169a24fa 10. /build/src/Processors/ISource.cpp:108: DB::ISource::work() @ 0x00000000169a21e7 11. /build/src/Processors/Executors/StreamingFormatExecutor.cpp:77: DB::StreamingFormatExecutor::execute() @ 0x00000000169c44ca 12. /build/src/Processors/Executors/StreamingFormatExecutor.cpp:58: DB::StreamingFormatExecutor::execute(DB::ReadBuffer&) @ 0x00000000169c431c 13. /build/src/Interpreters/AsynchronousInsertQueue.cpp:1085: DB::AsynchronousInsertQueue::processData(DB::AsynchronousInsertQueue::InsertQuery, std::unique_ptr>, std::shared_ptr, DB::AsynchronousInsertQueue::QueueShardFlushTimeHistory&) @ 0x00000000143e3843 14. /build/src/Interpreters/AsynchronousInsertQueue.cpp:319: void std::__function::__policy_invoker::__call_impl[abi:se190107]>, std::shared_ptr, unsigned long)::$_0, void ()>>(std::__function::__policy_storage const*) @ 0x00000000143e6d04 15. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc6653 16. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000000fccc4c3 17. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc3d92 18. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fcca080 19. ? @ 0x00007fbc6213eac3 20. ? @ 0x00007fbc621d0850 2025.07.28 12:00:00.468866 [ 17557 ] {} TCPHandler: TCPHandler: Code: 81. DB::Exception: Database test_11 does not exist. Maybe you meant test_1?. (UNKNOWN_DATABASE), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000a06a8eb 4. /build/src/Interpreters/DatabaseCatalog.cpp:535: DB::DatabaseCatalog::assertDatabaseExists(String const&) const @ 0x00000000144f31f6 5. /build/src/Server/TCPHandler.cpp:342: DB::TCPHandler::runImpl() @ 0x00000000168e5a19 6. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 7. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 8. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 9. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 10. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 11. ? @ 0x00007fbc6213eac3 12. ? @ 0x00007fbc621d0850 (version 25.3.6.10636.altinitytest (altinity build)) 2025.07.28 12:00:00.473055 [ 17557 ] {} ServerErrorHandler: Code: 81. DB::Exception: Database test_11 does not exist. Maybe you meant test_1?. (UNKNOWN_DATABASE), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000a06a8eb 4. /build/src/Interpreters/DatabaseCatalog.cpp:535: DB::DatabaseCatalog::assertDatabaseExists(String const&) const @ 0x00000000144f31f6 5. /build/src/Server/TCPHandler.cpp:342: DB::TCPHandler::runImpl() @ 0x00000000168e5a19 6. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 7. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 8. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 9. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 10. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 11. ? @ 0x00007fbc6213eac3 12. ? @ 0x00007fbc621d0850 (version 25.3.6.10636.altinitytest (altinity build)) 2025.07.28 12:00:00.565893 [ 17191 ] {} TCPHandler: TCPHandler: Code: 81. DB::Exception: Database test_11 does not exist. Maybe you meant test_1?. (UNKNOWN_DATABASE), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000a06a8eb 4. /build/src/Interpreters/DatabaseCatalog.cpp:535: DB::DatabaseCatalog::assertDatabaseExists(String const&) const @ 0x00000000144f31f6 5. /build/src/Server/TCPHandler.cpp:342: DB::TCPHandler::runImpl() @ 0x00000000168e5a19 6. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 7. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 8. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 9. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 10. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 11. ? @ 0x00007fbc6213eac3 12. ? @ 0x00007fbc621d0850 (version 25.3.6.10636.altinitytest (altinity build)) 2025.07.28 12:00:00.567808 [ 17191 ] {} ServerErrorHandler: Code: 81. DB::Exception: Database test_11 does not exist. Maybe you meant test_1?. (UNKNOWN_DATABASE), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000a06a8eb 4. /build/src/Interpreters/DatabaseCatalog.cpp:535: DB::DatabaseCatalog::assertDatabaseExists(String const&) const @ 0x00000000144f31f6 5. /build/src/Server/TCPHandler.cpp:342: DB::TCPHandler::runImpl() @ 0x00000000168e5a19 6. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 7. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 8. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 9. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 10. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 11. ? @ 0x00007fbc6213eac3 12. ? @ 0x00007fbc621d0850 (version 25.3.6.10636.altinitytest (altinity build)) 2025.07.28 12:00:00.715986 [ 17191 ] {} TCPHandler: TCPHandler: Code: 81. DB::Exception: Database test_11 does not exist. Maybe you meant test_1?. (UNKNOWN_DATABASE), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000a06a8eb 4. /build/src/Interpreters/DatabaseCatalog.cpp:535: DB::DatabaseCatalog::assertDatabaseExists(String const&) const @ 0x00000000144f31f6 5. /build/src/Server/TCPHandler.cpp:342: DB::TCPHandler::runImpl() @ 0x00000000168e5a19 6. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 7. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 8. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 9. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 10. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 11. ? @ 0x00007fbc6213eac3 12. ? @ 0x00007fbc621d0850 (version 25.3.6.10636.altinitytest (altinity build)) 2025.07.28 12:00:00.716746 [ 17191 ] {} ServerErrorHandler: Code: 81. DB::Exception: Database test_11 does not exist. Maybe you meant test_1?. (UNKNOWN_DATABASE), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000a06a8eb 4. /build/src/Interpreters/DatabaseCatalog.cpp:535: DB::DatabaseCatalog::assertDatabaseExists(String const&) const @ 0x00000000144f31f6 5. /build/src/Server/TCPHandler.cpp:342: DB::TCPHandler::runImpl() @ 0x00000000168e5a19 6. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 7. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 8. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 9. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 10. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 11. ? @ 0x00007fbc6213eac3 12. ? @ 0x00007fbc621d0850 (version 25.3.6.10636.altinitytest (altinity build)) 2025.07.28 12:00:00.826323 [ 3966 ] {} test_13.rmt2 (7f9b740d-015c-470e-8cc6-8ba33be0dc63): auto DB::StorageReplicatedMergeTree::processQueueEntry(ReplicatedMergeTreeQueue::SelectedEntryPtr)::(anonymous class)::operator()(LogEntryPtr &) const: Code: 86. DB::HTTPException: Received error from remote server http://146b4357c08d:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Ftest%2F01165%2Ftest_13%2Frmt%2Freplicas%2F1&part=20250728_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.6.10636.altinitytest (altinity build)) '. (RECEIVED_ERROR_FROM_REMOTE_IO_SERVER), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.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 const&, int&&, String const&, unsigned long&&, String const&) @ 0x000000000feda8d9 4. /build/src/IO/HTTPCommon.cpp:104: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x000000000feda6e2 5. /build/src/IO/HTTPCommon.cpp:93: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x000000000feda537 6. /build/src/IO/ReadWriteBufferFromHTTP.cpp:277: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x000000001184a4c4 7. /build/src/IO/ReadWriteBufferFromHTTP.cpp:285: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x000000001184a615 8. /build/src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x000000001184ae59 9. /build/src/IO/ReadWriteBufferFromHTTP.cpp:472: void std::__function::__policy_invoker::__call_impl[abi:se190107]>(std::__function::__policy_storage const*) @ 0x000000001184cedd 10. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001184858b 11. /build/src/IO/ReadWriteBufferFromHTTP.cpp:465: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x000000001184bf0b 12. /build/src/IO/ReadBuffer.h:60: DB::ReadBuffer::next() @ 0x000000000a148c7b 13. /build/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) @ 0x0000000011849fb2 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]>&)>&, 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&) @ 0x0000000011841980 15. /build/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) @ 0x000000001621208e 16. /build/src/Storages/StorageReplicatedMergeTree.cpp:5228: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl[abi:se190107] const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000015f9a5fe 17. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000015ed8bfd 18. /build/src/Storages/StorageReplicatedMergeTree.cpp:2514: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x0000000015ec9aab 19. /build/src/Storages/StorageReplicatedMergeTree.cpp:2349: DB::StorageReplicatedMergeTree::executeLogEntry(DB::ReplicatedMergeTreeLogEntry&) @ 0x0000000015eba91b 20. /build/src/Storages/StorageReplicatedMergeTree.cpp:3876: bool std::__function::__policy_invoker&)>::__call_impl[abi:se190107])::$_1, bool (std::shared_ptr&)>>(std::__function::__policy_storage const*, std::shared_ptr&) @ 0x0000000015f9837e 21. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000165d6fc3 22. /build/src/Storages/StorageReplicatedMergeTree.cpp:3872: DB::StorageReplicatedMergeTree::processQueueEntry(std::shared_ptr) @ 0x0000000015efc18a 23. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001624c1b2 24. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000162f9c70 25. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x00000000162fa55a 26. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc6653 27. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000000fccc4c3 28. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc3d92 29. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fcca080 30. ? @ 0x00007fbc6213eac3 31. ? @ 0x00007fbc621d0850 (version 25.3.6.10636.altinitytest (altinity build)) 2025.07.28 12:00:00.835219 [ 11851 ] {} TCPHandler: TCPHandler: Code: 81. DB::Exception: Database test_11 does not exist. Maybe you meant test_1?. (UNKNOWN_DATABASE), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000a06a8eb 4. /build/src/Interpreters/DatabaseCatalog.cpp:535: DB::DatabaseCatalog::assertDatabaseExists(String const&) const @ 0x00000000144f31f6 5. /build/src/Server/TCPHandler.cpp:342: DB::TCPHandler::runImpl() @ 0x00000000168e5a19 6. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 7. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 8. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 9. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 10. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 11. ? @ 0x00007fbc6213eac3 12. ? @ 0x00007fbc621d0850 (version 25.3.6.10636.altinitytest (altinity build)) 2025.07.28 12:00:00.835975 [ 11851 ] {} ServerErrorHandler: Code: 81. DB::Exception: Database test_11 does not exist. Maybe you meant test_1?. (UNKNOWN_DATABASE), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000a06a8eb 4. /build/src/Interpreters/DatabaseCatalog.cpp:535: DB::DatabaseCatalog::assertDatabaseExists(String const&) const @ 0x00000000144f31f6 5. /build/src/Server/TCPHandler.cpp:342: DB::TCPHandler::runImpl() @ 0x00000000168e5a19 6. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 7. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 8. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 9. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 10. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 11. ? @ 0x00007fbc6213eac3 12. ? @ 0x00007fbc621d0850 (version 25.3.6.10636.altinitytest (altinity build)) 2025.07.28 12:00:00.971952 [ 11851 ] {} TCPHandler: TCPHandler: Code: 81. DB::Exception: Database test_11 does not exist. Maybe you meant test_1?. (UNKNOWN_DATABASE), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000a06a8eb 4. /build/src/Interpreters/DatabaseCatalog.cpp:535: DB::DatabaseCatalog::assertDatabaseExists(String const&) const @ 0x00000000144f31f6 5. /build/src/Server/TCPHandler.cpp:342: DB::TCPHandler::runImpl() @ 0x00000000168e5a19 6. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 7. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 8. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 9. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 10. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 11. ? @ 0x00007fbc6213eac3 12. ? @ 0x00007fbc621d0850 (version 25.3.6.10636.altinitytest (altinity build)) 2025.07.28 12:00:00.972670 [ 11851 ] {} ServerErrorHandler: Code: 81. DB::Exception: Database test_11 does not exist. Maybe you meant test_1?. (UNKNOWN_DATABASE), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000a06a8eb 4. /build/src/Interpreters/DatabaseCatalog.cpp:535: DB::DatabaseCatalog::assertDatabaseExists(String const&) const @ 0x00000000144f31f6 5. /build/src/Server/TCPHandler.cpp:342: DB::TCPHandler::runImpl() @ 0x00000000168e5a19 6. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 7. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 8. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 9. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 10. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 11. ? @ 0x00007fbc6213eac3 12. ? @ 0x00007fbc621d0850 (version 25.3.6.10636.altinitytest (altinity build)) 2025.07.28 12:00:01.164440 [ 17191 ] {} TCPHandler: TCPHandler: Code: 81. DB::Exception: Database test_11 does not exist. Maybe you meant test_1?. (UNKNOWN_DATABASE), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000a06a8eb 4. /build/src/Interpreters/DatabaseCatalog.cpp:535: DB::DatabaseCatalog::assertDatabaseExists(String const&) const @ 0x00000000144f31f6 5. /build/src/Server/TCPHandler.cpp:342: DB::TCPHandler::runImpl() @ 0x00000000168e5a19 6. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 7. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 8. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 9. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 10. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 11. ? @ 0x00007fbc6213eac3 12. ? @ 0x00007fbc621d0850 (version 25.3.6.10636.altinitytest (altinity build)) 2025.07.28 12:00:01.165085 [ 17191 ] {} ServerErrorHandler: Code: 81. DB::Exception: Database test_11 does not exist. Maybe you meant test_1?. (UNKNOWN_DATABASE), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000a06a8eb 4. /build/src/Interpreters/DatabaseCatalog.cpp:535: DB::DatabaseCatalog::assertDatabaseExists(String const&) const @ 0x00000000144f31f6 5. /build/src/Server/TCPHandler.cpp:342: DB::TCPHandler::runImpl() @ 0x00000000168e5a19 6. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 7. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 8. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 9. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 10. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 11. ? @ 0x00007fbc6213eac3 12. ? @ 0x00007fbc621d0850 (version 25.3.6.10636.altinitytest (altinity build)) 2025.07.28 12:00:01.323043 [ 17191 ] {} TCPHandler: TCPHandler: Code: 81. DB::Exception: Database test_11 does not exist. Maybe you meant test_1?. (UNKNOWN_DATABASE), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000a06a8eb 4. /build/src/Interpreters/DatabaseCatalog.cpp:535: DB::DatabaseCatalog::assertDatabaseExists(String const&) const @ 0x00000000144f31f6 5. /build/src/Server/TCPHandler.cpp:342: DB::TCPHandler::runImpl() @ 0x00000000168e5a19 6. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 7. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 8. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 9. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 10. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 11. ? @ 0x00007fbc6213eac3 12. ? @ 0x00007fbc621d0850 (version 25.3.6.10636.altinitytest (altinity build)) 2025.07.28 12:00:01.323823 [ 17191 ] {} ServerErrorHandler: Code: 81. DB::Exception: Database test_11 does not exist. Maybe you meant test_1?. (UNKNOWN_DATABASE), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000a06a8eb 4. /build/src/Interpreters/DatabaseCatalog.cpp:535: DB::DatabaseCatalog::assertDatabaseExists(String const&) const @ 0x00000000144f31f6 5. /build/src/Server/TCPHandler.cpp:342: DB::TCPHandler::runImpl() @ 0x00000000168e5a19 6. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 7. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 8. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 9. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 10. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 11. ? @ 0x00007fbc6213eac3 12. ? @ 0x00007fbc621d0850 (version 25.3.6.10636.altinitytest (altinity build)) 2025.07.28 12:00:01.375827 [ 5852 ] {1b0e70f7-10c5-4c3c-9d8e-c5016f607aa3} AsynchronousInsertQueue: Failed parsing for query 'INSERT INTO test_5.t_json_async_insert (data) FORMAT JSONAsObject' with query id d64a24a1-ce69-4528-9d9a-c686ae809fa5. DB::Exception: Cannot parse JSON object here: {"aaa"}: (at row 1) 2025.07.28 12:00:01.384053 [ 17611 ] {d64a24a1-ce69-4528-9d9a-c686ae809fa5} executeQuery: Code: 117. DB::Exception: Cannot parse JSON object here: {"aaa"}: (at row 1) : While executing WaitForAsyncInsert. (INCORRECT_DATA) (version 25.3.6.10636.altinitytest (altinity build)) (from [::1]:39346) (comment: 02421_new_type_json_async_insert.sh) (query 1, line 1) (in query: INSERT INTO t_json_async_insert FORMAT JSONAsObject ), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x000000000c25bc4b 4. /build/src/DataTypes/Serializations/SerializationJSON.cpp:299: DB::SerializationJSON::deserializeObject(DB::IColumn&, std::basic_string_view>, DB::FormatSettings const&) const @ 0x0000000013cbaf0d 5. /build/src/DataTypes/Serializations/SerializationJSON.cpp:393: DB::SerializationJSON::deserializeTextJSON(DB::IColumn&, DB::ReadBuffer&, DB::FormatSettings const&) const @ 0x0000000013cbabe6 6. /build/src/Processors/Formats/Impl/JSONAsStringRowInputFormat.cpp:52: DB::JSONAsRowInputFormat::readRow(std::vector::mutable_ptr, std::allocator::mutable_ptr>>&, DB::RowReadExtension&) @ 0x0000000016ac0869 7. /build/src/Processors/Formats/IRowInputFormat.cpp:143: DB::IRowInputFormat::read() @ 0x0000000016a1fc72 8. /build/src/Processors/Formats/IInputFormat.cpp:19: DB::IInputFormat::generate() @ 0x00000000169c5536 9. /build/src/Processors/ISource.cpp:139: DB::ISource::tryGenerate() @ 0x00000000169a24fa 10. /build/src/Processors/ISource.cpp:108: DB::ISource::work() @ 0x00000000169a21e7 11. /build/src/Processors/Executors/StreamingFormatExecutor.cpp:77: DB::StreamingFormatExecutor::execute() @ 0x00000000169c44ca 12. /build/src/Processors/Executors/StreamingFormatExecutor.cpp:58: DB::StreamingFormatExecutor::execute(DB::ReadBuffer&) @ 0x00000000169c431c 13. /build/src/Interpreters/AsynchronousInsertQueue.cpp:1085: DB::AsynchronousInsertQueue::processData(DB::AsynchronousInsertQueue::InsertQuery, std::unique_ptr>, std::shared_ptr, DB::AsynchronousInsertQueue::QueueShardFlushTimeHistory&) @ 0x00000000143e3843 14. /build/src/Interpreters/AsynchronousInsertQueue.cpp:319: void std::__function::__policy_invoker::__call_impl[abi:se190107]>, std::shared_ptr, unsigned long)::$_0, void ()>>(std::__function::__policy_storage const*) @ 0x00000000143e6d04 15. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc6653 16. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000000fccc4c3 17. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc3d92 18. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fcca080 19. ? @ 0x00007fbc6213eac3 20. ? @ 0x00007fbc621d0850 2025.07.28 12:00:01.470748 [ 17611 ] {} TCPHandler: Code: 117. DB::Exception: Cannot parse JSON object here: {"aaa"}: (at row 1) : While executing WaitForAsyncInsert. (INCORRECT_DATA), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x000000000c25bc4b 4. /build/src/DataTypes/Serializations/SerializationJSON.cpp:299: DB::SerializationJSON::deserializeObject(DB::IColumn&, std::basic_string_view>, DB::FormatSettings const&) const @ 0x0000000013cbaf0d 5. /build/src/DataTypes/Serializations/SerializationJSON.cpp:393: DB::SerializationJSON::deserializeTextJSON(DB::IColumn&, DB::ReadBuffer&, DB::FormatSettings const&) const @ 0x0000000013cbabe6 6. /build/src/Processors/Formats/Impl/JSONAsStringRowInputFormat.cpp:52: DB::JSONAsRowInputFormat::readRow(std::vector::mutable_ptr, std::allocator::mutable_ptr>>&, DB::RowReadExtension&) @ 0x0000000016ac0869 7. /build/src/Processors/Formats/IRowInputFormat.cpp:143: DB::IRowInputFormat::read() @ 0x0000000016a1fc72 8. /build/src/Processors/Formats/IInputFormat.cpp:19: DB::IInputFormat::generate() @ 0x00000000169c5536 9. /build/src/Processors/ISource.cpp:139: DB::ISource::tryGenerate() @ 0x00000000169a24fa 10. /build/src/Processors/ISource.cpp:108: DB::ISource::work() @ 0x00000000169a21e7 11. /build/src/Processors/Executors/StreamingFormatExecutor.cpp:77: DB::StreamingFormatExecutor::execute() @ 0x00000000169c44ca 12. /build/src/Processors/Executors/StreamingFormatExecutor.cpp:58: DB::StreamingFormatExecutor::execute(DB::ReadBuffer&) @ 0x00000000169c431c 13. /build/src/Interpreters/AsynchronousInsertQueue.cpp:1085: DB::AsynchronousInsertQueue::processData(DB::AsynchronousInsertQueue::InsertQuery, std::unique_ptr>, std::shared_ptr, DB::AsynchronousInsertQueue::QueueShardFlushTimeHistory&) @ 0x00000000143e3843 14. /build/src/Interpreters/AsynchronousInsertQueue.cpp:319: void std::__function::__policy_invoker::__call_impl[abi:se190107]>, std::shared_ptr, unsigned long)::$_0, void ()>>(std::__function::__policy_storage const*) @ 0x00000000143e6d04 15. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc6653 16. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000000fccc4c3 17. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc3d92 18. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fcca080 19. ? @ 0x00007fbc6213eac3 20. ? @ 0x00007fbc621d0850 2025.07.28 12:00:01.502784 [ 17207 ] {} TCPHandler: TCPHandler: Code: 81. DB::Exception: Database test_11 does not exist. Maybe you meant test_1?. (UNKNOWN_DATABASE), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000a06a8eb 4. /build/src/Interpreters/DatabaseCatalog.cpp:535: DB::DatabaseCatalog::assertDatabaseExists(String const&) const @ 0x00000000144f31f6 5. /build/src/Server/TCPHandler.cpp:342: DB::TCPHandler::runImpl() @ 0x00000000168e5a19 6. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 7. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 8. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 9. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 10. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 11. ? @ 0x00007fbc6213eac3 12. ? @ 0x00007fbc621d0850 (version 25.3.6.10636.altinitytest (altinity build)) 2025.07.28 12:00:01.503563 [ 17207 ] {} ServerErrorHandler: Code: 81. DB::Exception: Database test_11 does not exist. Maybe you meant test_1?. (UNKNOWN_DATABASE), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000a06a8eb 4. /build/src/Interpreters/DatabaseCatalog.cpp:535: DB::DatabaseCatalog::assertDatabaseExists(String const&) const @ 0x00000000144f31f6 5. /build/src/Server/TCPHandler.cpp:342: DB::TCPHandler::runImpl() @ 0x00000000168e5a19 6. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 7. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 8. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 9. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 10. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 11. ? @ 0x00007fbc6213eac3 12. ? @ 0x00007fbc621d0850 (version 25.3.6.10636.altinitytest (altinity build)) 2025.07.28 12:00:01.504389 [ 3970 ] {} test_13.rmt2 (7f9b740d-015c-470e-8cc6-8ba33be0dc63): auto DB::StorageReplicatedMergeTree::processQueueEntry(ReplicatedMergeTreeQueue::SelectedEntryPtr)::(anonymous class)::operator()(LogEntryPtr &) const: Code: 86. DB::HTTPException: Received error from remote server http://146b4357c08d:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Ftest%2F01165%2Ftest_13%2Frmt%2Freplicas%2F1&part=20250728_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.6.10636.altinitytest (altinity build)) '. (RECEIVED_ERROR_FROM_REMOTE_IO_SERVER), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.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 const&, int&&, String const&, unsigned long&&, String const&) @ 0x000000000feda8d9 4. /build/src/IO/HTTPCommon.cpp:104: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x000000000feda6e2 5. /build/src/IO/HTTPCommon.cpp:93: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x000000000feda537 6. /build/src/IO/ReadWriteBufferFromHTTP.cpp:277: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x000000001184a4c4 7. /build/src/IO/ReadWriteBufferFromHTTP.cpp:285: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x000000001184a615 8. /build/src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x000000001184ae59 9. /build/src/IO/ReadWriteBufferFromHTTP.cpp:472: void std::__function::__policy_invoker::__call_impl[abi:se190107]>(std::__function::__policy_storage const*) @ 0x000000001184cedd 10. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001184858b 11. /build/src/IO/ReadWriteBufferFromHTTP.cpp:465: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x000000001184bf0b 12. /build/src/IO/ReadBuffer.h:60: DB::ReadBuffer::next() @ 0x000000000a148c7b 13. /build/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) @ 0x0000000011849fb2 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]>&)>&, 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&) @ 0x0000000011841980 15. /build/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) @ 0x000000001621208e 16. /build/src/Storages/StorageReplicatedMergeTree.cpp:5228: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl[abi:se190107] const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000015f9a5fe 17. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000015ed8bfd 18. /build/src/Storages/StorageReplicatedMergeTree.cpp:2514: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x0000000015ec9aab 19. /build/src/Storages/StorageReplicatedMergeTree.cpp:2349: DB::StorageReplicatedMergeTree::executeLogEntry(DB::ReplicatedMergeTreeLogEntry&) @ 0x0000000015eba91b 20. /build/src/Storages/StorageReplicatedMergeTree.cpp:3876: bool std::__function::__policy_invoker&)>::__call_impl[abi:se190107])::$_1, bool (std::shared_ptr&)>>(std::__function::__policy_storage const*, std::shared_ptr&) @ 0x0000000015f9837e 21. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000165d6fc3 22. /build/src/Storages/StorageReplicatedMergeTree.cpp:3872: DB::StorageReplicatedMergeTree::processQueueEntry(std::shared_ptr) @ 0x0000000015efc18a 23. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001624c1b2 24. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000162f9c70 25. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x00000000162fa55a 26. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc6653 27. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000000fccc4c3 28. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc3d92 29. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fcca080 30. ? @ 0x00007fbc6213eac3 31. ? @ 0x00007fbc621d0850 (version 25.3.6.10636.altinitytest (altinity build)) 2025.07.28 12:00:02.028716 [ 3968 ] {} test_13.rmt2 (7f9b740d-015c-470e-8cc6-8ba33be0dc63): auto DB::StorageReplicatedMergeTree::processQueueEntry(ReplicatedMergeTreeQueue::SelectedEntryPtr)::(anonymous class)::operator()(LogEntryPtr &) const: Code: 86. DB::HTTPException: Received error from remote server http://146b4357c08d:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Ftest%2F01165%2Ftest_13%2Frmt%2Freplicas%2F1&part=20250728_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.6.10636.altinitytest (altinity build)) '. (RECEIVED_ERROR_FROM_REMOTE_IO_SERVER), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.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 const&, int&&, String const&, unsigned long&&, String const&) @ 0x000000000feda8d9 4. /build/src/IO/HTTPCommon.cpp:104: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x000000000feda6e2 5. /build/src/IO/HTTPCommon.cpp:93: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x000000000feda537 6. /build/src/IO/ReadWriteBufferFromHTTP.cpp:277: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x000000001184a4c4 7. /build/src/IO/ReadWriteBufferFromHTTP.cpp:285: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x000000001184a615 8. /build/src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x000000001184ae59 9. /build/src/IO/ReadWriteBufferFromHTTP.cpp:472: void std::__function::__policy_invoker::__call_impl[abi:se190107]>(std::__function::__policy_storage const*) @ 0x000000001184cedd 10. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001184858b 11. /build/src/IO/ReadWriteBufferFromHTTP.cpp:465: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x000000001184bf0b 12. /build/src/IO/ReadBuffer.h:60: DB::ReadBuffer::next() @ 0x000000000a148c7b 13. /build/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) @ 0x0000000011849fb2 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]>&)>&, 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&) @ 0x0000000011841980 15. /build/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) @ 0x000000001621208e 16. /build/src/Storages/StorageReplicatedMergeTree.cpp:5228: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl[abi:se190107] const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000015f9a5fe 17. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000015ed8bfd 18. /build/src/Storages/StorageReplicatedMergeTree.cpp:2514: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x0000000015ec9aab 19. /build/src/Storages/StorageReplicatedMergeTree.cpp:2349: DB::StorageReplicatedMergeTree::executeLogEntry(DB::ReplicatedMergeTreeLogEntry&) @ 0x0000000015eba91b 20. /build/src/Storages/StorageReplicatedMergeTree.cpp:3876: bool std::__function::__policy_invoker&)>::__call_impl[abi:se190107])::$_1, bool (std::shared_ptr&)>>(std::__function::__policy_storage const*, std::shared_ptr&) @ 0x0000000015f9837e 21. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000165d6fc3 22. /build/src/Storages/StorageReplicatedMergeTree.cpp:3872: DB::StorageReplicatedMergeTree::processQueueEntry(std::shared_ptr) @ 0x0000000015efc18a 23. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001624c1b2 24. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000162f9c70 25. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x00000000162fa55a 26. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc6653 27. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000000fccc4c3 28. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc3d92 29. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fcca080 30. ? @ 0x00007fbc6213eac3 31. ? @ 0x00007fbc621d0850 (version 25.3.6.10636.altinitytest (altinity build)) 2025.07.28 12:00:02.216724 [ 3974 ] {} test_13.rmt2 (7f9b740d-015c-470e-8cc6-8ba33be0dc63): auto DB::StorageReplicatedMergeTree::processQueueEntry(ReplicatedMergeTreeQueue::SelectedEntryPtr)::(anonymous class)::operator()(LogEntryPtr &) const: Code: 86. DB::HTTPException: Received error from remote server http://146b4357c08d:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Ftest%2F01165%2Ftest_13%2Frmt%2Freplicas%2F1&part=20250728_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.6.10636.altinitytest (altinity build)) '. (RECEIVED_ERROR_FROM_REMOTE_IO_SERVER), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.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 const&, int&&, String const&, unsigned long&&, String const&) @ 0x000000000feda8d9 4. /build/src/IO/HTTPCommon.cpp:104: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x000000000feda6e2 5. /build/src/IO/HTTPCommon.cpp:93: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x000000000feda537 6. /build/src/IO/ReadWriteBufferFromHTTP.cpp:277: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x000000001184a4c4 7. /build/src/IO/ReadWriteBufferFromHTTP.cpp:285: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x000000001184a615 8. /build/src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x000000001184ae59 9. /build/src/IO/ReadWriteBufferFromHTTP.cpp:472: void std::__function::__policy_invoker::__call_impl[abi:se190107]>(std::__function::__policy_storage const*) @ 0x000000001184cedd 10. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001184858b 11. /build/src/IO/ReadWriteBufferFromHTTP.cpp:465: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x000000001184bf0b 12. /build/src/IO/ReadBuffer.h:60: DB::ReadBuffer::next() @ 0x000000000a148c7b 13. /build/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) @ 0x0000000011849fb2 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]>&)>&, 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&) @ 0x0000000011841980 15. /build/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) @ 0x000000001621208e 16. /build/src/Storages/StorageReplicatedMergeTree.cpp:5228: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl[abi:se190107] const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000015f9a5fe 17. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000015ed8bfd 18. /build/src/Storages/StorageReplicatedMergeTree.cpp:2514: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x0000000015ec9aab 19. /build/src/Storages/StorageReplicatedMergeTree.cpp:2349: DB::StorageReplicatedMergeTree::executeLogEntry(DB::ReplicatedMergeTreeLogEntry&) @ 0x0000000015eba91b 20. /build/src/Storages/StorageReplicatedMergeTree.cpp:3876: bool std::__function::__policy_invoker&)>::__call_impl[abi:se190107])::$_1, bool (std::shared_ptr&)>>(std::__function::__policy_storage const*, std::shared_ptr&) @ 0x0000000015f9837e 21. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000165d6fc3 22. /build/src/Storages/StorageReplicatedMergeTree.cpp:3872: DB::StorageReplicatedMergeTree::processQueueEntry(std::shared_ptr) @ 0x0000000015efc18a 23. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001624c1b2 24. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000162f9c70 25. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x00000000162fa55a 26. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc6653 27. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000000fccc4c3 28. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc3d92 29. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fcca080 30. ? @ 0x00007fbc6213eac3 31. ? @ 0x00007fbc621d0850 (version 25.3.6.10636.altinitytest (altinity build)) 2025.07.28 12:00:02.736101 [ 3972 ] {} test_13.rmt2 (7f9b740d-015c-470e-8cc6-8ba33be0dc63): auto DB::StorageReplicatedMergeTree::processQueueEntry(ReplicatedMergeTreeQueue::SelectedEntryPtr)::(anonymous class)::operator()(LogEntryPtr &) const: Code: 86. DB::HTTPException: Received error from remote server http://146b4357c08d:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Ftest%2F01165%2Ftest_13%2Frmt%2Freplicas%2F1&part=20250728_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.6.10636.altinitytest (altinity build)) '. (RECEIVED_ERROR_FROM_REMOTE_IO_SERVER), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.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 const&, int&&, String const&, unsigned long&&, String const&) @ 0x000000000feda8d9 4. /build/src/IO/HTTPCommon.cpp:104: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x000000000feda6e2 5. /build/src/IO/HTTPCommon.cpp:93: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x000000000feda537 6. /build/src/IO/ReadWriteBufferFromHTTP.cpp:277: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x000000001184a4c4 7. /build/src/IO/ReadWriteBufferFromHTTP.cpp:285: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x000000001184a615 8. /build/src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x000000001184ae59 9. /build/src/IO/ReadWriteBufferFromHTTP.cpp:472: void std::__function::__policy_invoker::__call_impl[abi:se190107]>(std::__function::__policy_storage const*) @ 0x000000001184cedd 10. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001184858b 11. /build/src/IO/ReadWriteBufferFromHTTP.cpp:465: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x000000001184bf0b 12. /build/src/IO/ReadBuffer.h:60: DB::ReadBuffer::next() @ 0x000000000a148c7b 13. /build/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) @ 0x0000000011849fb2 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]>&)>&, 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&) @ 0x0000000011841980 15. /build/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) @ 0x000000001621208e 16. /build/src/Storages/StorageReplicatedMergeTree.cpp:5228: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl[abi:se190107] const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000015f9a5fe 17. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000015ed8bfd 18. /build/src/Storages/StorageReplicatedMergeTree.cpp:2514: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x0000000015ec9aab 19. /build/src/Storages/StorageReplicatedMergeTree.cpp:2349: DB::StorageReplicatedMergeTree::executeLogEntry(DB::ReplicatedMergeTreeLogEntry&) @ 0x0000000015eba91b 20. /build/src/Storages/StorageReplicatedMergeTree.cpp:3876: bool std::__function::__policy_invoker&)>::__call_impl[abi:se190107])::$_1, bool (std::shared_ptr&)>>(std::__function::__policy_storage const*, std::shared_ptr&) @ 0x0000000015f9837e 21. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000165d6fc3 22. /build/src/Storages/StorageReplicatedMergeTree.cpp:3872: DB::StorageReplicatedMergeTree::processQueueEntry(std::shared_ptr) @ 0x0000000015efc18a 23. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001624c1b2 24. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000162f9c70 25. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x00000000162fa55a 26. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc6653 27. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000000fccc4c3 28. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc3d92 29. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fcca080 30. ? @ 0x00007fbc6213eac3 31. ? @ 0x00007fbc621d0850 (version 25.3.6.10636.altinitytest (altinity build)) 2025.07.28 12:00:03.474616 [ 3960 ] {} test_13.rmt2 (7f9b740d-015c-470e-8cc6-8ba33be0dc63): auto DB::StorageReplicatedMergeTree::processQueueEntry(ReplicatedMergeTreeQueue::SelectedEntryPtr)::(anonymous class)::operator()(LogEntryPtr &) const: Code: 86. DB::HTTPException: Received error from remote server http://146b4357c08d:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Ftest%2F01165%2Ftest_13%2Frmt%2Freplicas%2F1&part=20250728_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.6.10636.altinitytest (altinity build)) '. (RECEIVED_ERROR_FROM_REMOTE_IO_SERVER), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.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 const&, int&&, String const&, unsigned long&&, String const&) @ 0x000000000feda8d9 4. /build/src/IO/HTTPCommon.cpp:104: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x000000000feda6e2 5. /build/src/IO/HTTPCommon.cpp:93: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x000000000feda537 6. /build/src/IO/ReadWriteBufferFromHTTP.cpp:277: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x000000001184a4c4 7. /build/src/IO/ReadWriteBufferFromHTTP.cpp:285: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x000000001184a615 8. /build/src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x000000001184ae59 9. /build/src/IO/ReadWriteBufferFromHTTP.cpp:472: void std::__function::__policy_invoker::__call_impl[abi:se190107]>(std::__function::__policy_storage const*) @ 0x000000001184cedd 10. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001184858b 11. /build/src/IO/ReadWriteBufferFromHTTP.cpp:465: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x000000001184bf0b 12. /build/src/IO/ReadBuffer.h:60: DB::ReadBuffer::next() @ 0x000000000a148c7b 13. /build/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) @ 0x0000000011849fb2 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]>&)>&, 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&) @ 0x0000000011841980 15. /build/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) @ 0x000000001621208e 16. /build/src/Storages/StorageReplicatedMergeTree.cpp:5228: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl[abi:se190107] const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000015f9a5fe 17. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000015ed8bfd 18. /build/src/Storages/StorageReplicatedMergeTree.cpp:2514: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x0000000015ec9aab 19. /build/src/Storages/StorageReplicatedMergeTree.cpp:2349: DB::StorageReplicatedMergeTree::executeLogEntry(DB::ReplicatedMergeTreeLogEntry&) @ 0x0000000015eba91b 20. /build/src/Storages/StorageReplicatedMergeTree.cpp:3876: bool std::__function::__policy_invoker&)>::__call_impl[abi:se190107])::$_1, bool (std::shared_ptr&)>>(std::__function::__policy_storage const*, std::shared_ptr&) @ 0x0000000015f9837e 21. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000165d6fc3 22. /build/src/Storages/StorageReplicatedMergeTree.cpp:3872: DB::StorageReplicatedMergeTree::processQueueEntry(std::shared_ptr) @ 0x0000000015efc18a 23. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001624c1b2 24. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000162f9c70 25. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x00000000162fa55a 26. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc6653 27. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000000fccc4c3 28. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc3d92 29. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fcca080 30. ? @ 0x00007fbc6213eac3 31. ? @ 0x00007fbc621d0850 (version 25.3.6.10636.altinitytest (altinity build)) 2025.07.28 12:00:03.638701 [ 5327 ] {9d6aeb4f-e937-4626-aac7-33ed50351415} executeQuery: Code: 439. DB::Exception: Cannot schedule a task: failed to start the thread (threads=0, jobs=0). (CANNOT_SCHEDULE_TASK) (version 25.3.6.10636.altinitytest (altinity build)) (from [::1]:39032) (comment: 00091_union_race_conditions_2.sh) (query 14, line 14) (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. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000fccaeeb 4. /build/src/Common/ThreadPool.cpp:275: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000fccc813 5. /build/src/Common/ThreadPool.cpp:308: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fcc8286 6. /build/src/Common/ThreadPool.cpp:494: ThreadPoolImpl>::scheduleOrThrowOnError(std::function, Priority) @ 0x000000000fcc7a0e 7. /build/src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::spawnThreadsImpl() @ 0x00000000169b2c0c 8. /build/src/Processors/Executors/PipelineExecutor.cpp:394: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x00000000169b0ba7 9. /build/src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x00000000169b03f4 10. /build/src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:se190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169bfeab 11. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc3d92 12. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fcca080 13. ? @ 0x00007fbc6213eac3 14. ? @ 0x00007fbc621d0850 2025.07.28 12:00:03.659385 [ 5327 ] {} 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. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000fccaeeb 4. /build/src/Common/ThreadPool.cpp:275: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000fccc813 5. /build/src/Common/ThreadPool.cpp:308: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fcc8286 6. /build/src/Common/ThreadPool.cpp:494: ThreadPoolImpl>::scheduleOrThrowOnError(std::function, Priority) @ 0x000000000fcc7a0e 7. /build/src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::spawnThreadsImpl() @ 0x00000000169b2c0c 8. /build/src/Processors/Executors/PipelineExecutor.cpp:394: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x00000000169b0ba7 9. /build/src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x00000000169b03f4 10. /build/src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:se190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169bfeab 11. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc3d92 12. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fcca080 13. ? @ 0x00007fbc6213eac3 14. ? @ 0x00007fbc621d0850 Job's origin stack trace: 0. /build/src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000000fc33b84 1. /build/src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000000fcc2ea7 2. /build/src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fcc535c 3. /build/src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000000fcc584d 4. /build/src/Common/ThreadPool.h:279: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x00000000169bf193 5. /build/src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x00000000169bf518 6. /build/src/Server/TCPHandler.cpp:1237: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x00000000168f1525 7. /build/src/Server/TCPHandler.cpp:678: DB::TCPHandler::runImpl() @ 0x00000000168e68e5 8. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 9. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 10. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 11. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 12. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 13. ? @ 0x00007fbc6213eac3 14. ? @ 0x00007fbc621d0850 2025.07.28 12:00:04.056115 [ 3968 ] {} test_13.rmt2 (7f9b740d-015c-470e-8cc6-8ba33be0dc63): auto DB::StorageReplicatedMergeTree::processQueueEntry(ReplicatedMergeTreeQueue::SelectedEntryPtr)::(anonymous class)::operator()(LogEntryPtr &) const: Code: 86. DB::HTTPException: Received error from remote server http://146b4357c08d:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Ftest%2F01165%2Ftest_13%2Frmt%2Freplicas%2F1&part=20250728_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.6.10636.altinitytest (altinity build)) '. (RECEIVED_ERROR_FROM_REMOTE_IO_SERVER), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.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 const&, int&&, String const&, unsigned long&&, String const&) @ 0x000000000feda8d9 4. /build/src/IO/HTTPCommon.cpp:104: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x000000000feda6e2 5. /build/src/IO/HTTPCommon.cpp:93: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x000000000feda537 6. /build/src/IO/ReadWriteBufferFromHTTP.cpp:277: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x000000001184a4c4 7. /build/src/IO/ReadWriteBufferFromHTTP.cpp:285: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x000000001184a615 8. /build/src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x000000001184ae59 9. /build/src/IO/ReadWriteBufferFromHTTP.cpp:472: void std::__function::__policy_invoker::__call_impl[abi:se190107]>(std::__function::__policy_storage const*) @ 0x000000001184cedd 10. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001184858b 11. /build/src/IO/ReadWriteBufferFromHTTP.cpp:465: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x000000001184bf0b 12. /build/src/IO/ReadBuffer.h:60: DB::ReadBuffer::next() @ 0x000000000a148c7b 13. /build/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) @ 0x0000000011849fb2 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]>&)>&, 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&) @ 0x0000000011841980 15. /build/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) @ 0x000000001621208e 16. /build/src/Storages/StorageReplicatedMergeTree.cpp:5228: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl[abi:se190107] const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000015f9a5fe 17. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000015ed8bfd 18. /build/src/Storages/StorageReplicatedMergeTree.cpp:2514: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x0000000015ec9aab 19. /build/src/Storages/StorageReplicatedMergeTree.cpp:2349: DB::StorageReplicatedMergeTree::executeLogEntry(DB::ReplicatedMergeTreeLogEntry&) @ 0x0000000015eba91b 20. /build/src/Storages/StorageReplicatedMergeTree.cpp:3876: bool std::__function::__policy_invoker&)>::__call_impl[abi:se190107])::$_1, bool (std::shared_ptr&)>>(std::__function::__policy_storage const*, std::shared_ptr&) @ 0x0000000015f9837e 21. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000165d6fc3 22. /build/src/Storages/StorageReplicatedMergeTree.cpp:3872: DB::StorageReplicatedMergeTree::processQueueEntry(std::shared_ptr) @ 0x0000000015efc18a 23. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001624c1b2 24. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000162f9c70 25. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x00000000162fa55a 26. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc6653 27. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000000fccc4c3 28. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc3d92 29. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fcca080 30. ? @ 0x00007fbc6213eac3 31. ? @ 0x00007fbc621d0850 (version 25.3.6.10636.altinitytest (altinity build)) 2025.07.28 12:00:04.472395 [ 3970 ] {} test_13.rmt2 (7f9b740d-015c-470e-8cc6-8ba33be0dc63): auto DB::StorageReplicatedMergeTree::processQueueEntry(ReplicatedMergeTreeQueue::SelectedEntryPtr)::(anonymous class)::operator()(LogEntryPtr &) const: Code: 86. DB::HTTPException: Received error from remote server http://146b4357c08d:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Ftest%2F01165%2Ftest_13%2Frmt%2Freplicas%2F1&part=20250728_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.6.10636.altinitytest (altinity build)) '. (RECEIVED_ERROR_FROM_REMOTE_IO_SERVER), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.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 const&, int&&, String const&, unsigned long&&, String const&) @ 0x000000000feda8d9 4. /build/src/IO/HTTPCommon.cpp:104: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x000000000feda6e2 5. /build/src/IO/HTTPCommon.cpp:93: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x000000000feda537 6. /build/src/IO/ReadWriteBufferFromHTTP.cpp:277: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x000000001184a4c4 7. /build/src/IO/ReadWriteBufferFromHTTP.cpp:285: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x000000001184a615 8. /build/src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x000000001184ae59 9. /build/src/IO/ReadWriteBufferFromHTTP.cpp:472: void std::__function::__policy_invoker::__call_impl[abi:se190107]>(std::__function::__policy_storage const*) @ 0x000000001184cedd 10. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001184858b 11. /build/src/IO/ReadWriteBufferFromHTTP.cpp:465: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x000000001184bf0b 12. /build/src/IO/ReadBuffer.h:60: DB::ReadBuffer::next() @ 0x000000000a148c7b 13. /build/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) @ 0x0000000011849fb2 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]>&)>&, 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&) @ 0x0000000011841980 15. /build/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) @ 0x000000001621208e 16. /build/src/Storages/StorageReplicatedMergeTree.cpp:5228: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl[abi:se190107] const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000015f9a5fe 17. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000015ed8bfd 18. /build/src/Storages/StorageReplicatedMergeTree.cpp:2514: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x0000000015ec9aab 19. /build/src/Storages/StorageReplicatedMergeTree.cpp:2349: DB::StorageReplicatedMergeTree::executeLogEntry(DB::ReplicatedMergeTreeLogEntry&) @ 0x0000000015eba91b 20. /build/src/Storages/StorageReplicatedMergeTree.cpp:3876: bool std::__function::__policy_invoker&)>::__call_impl[abi:se190107])::$_1, bool (std::shared_ptr&)>>(std::__function::__policy_storage const*, std::shared_ptr&) @ 0x0000000015f9837e 21. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000165d6fc3 22. /build/src/Storages/StorageReplicatedMergeTree.cpp:3872: DB::StorageReplicatedMergeTree::processQueueEntry(std::shared_ptr) @ 0x0000000015efc18a 23. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001624c1b2 24. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000162f9c70 25. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x00000000162fa55a 26. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc6653 27. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000000fccc4c3 28. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc3d92 29. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fcca080 30. ? @ 0x00007fbc6213eac3 31. ? @ 0x00007fbc621d0850 (version 25.3.6.10636.altinitytest (altinity build)) 2025.07.28 12:00:04.727791 [ 17191 ] {ed9818d7-2e0e-4546-b17b-4f82c043a1f5} executeQuery: Code: 223. DB::Exception: [price, spend] is not an identifier. (UNEXPECTED_AST_STRUCTURE) (version 25.3.6.10636.altinitytest (altinity build)) (from [::1]:39432) (comment: 00983_summing_merge_tree_not_an_identifier.sql) (query 1, line 1) (in query: CREATE TABLE xx (`date` Date, `id` Int64, `clicks` Int64, `price` Float64, `spend` Float64) ENGINE = SummingMergeTree([price, spend]) PARTITION BY toYYYYMM(date) ORDER BY id SAMPLE BY id SETTINGS index_granularity = 8192, min_bytes_for_wide_part = 1073741824, ratio_of_defaults_for_sparse_serialization = 0., replace_long_file_name_to_hash = true, max_file_name_length = 67, min_bytes_for_full_part_storage = 270707773, compact_parts_max_bytes_to_buffer = 127174515, compact_parts_max_granules_to_buffer = 140, compact_parts_merge_max_bytes_to_prefetch_part = 18465082, merge_max_block_size = 16461, old_parts_lifetime = 11., prefer_fetch_merged_part_size_threshold = 3366081068, vertical_merge_algorithm_min_rows_to_activate = 1000000, vertical_merge_algorithm_min_columns_to_activate = 1, min_merge_bytes_to_use_direct_io = 10737418240, index_granularity_bytes = 25701428, use_const_adaptive_granularity = true, enable_index_granularity_compression = true, concurrent_part_removal_threshold = 0, allow_vertical_merges_from_compact_to_wide_parts = true, enable_block_number_column = false, enable_block_offset_column = true, cache_populated_by_fetch = true, marks_compress_block_size = 69589, primary_key_compress_block_size = 52123, 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. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x000000000a06b56b 4. /build/src/Parsers/ASTIdentifier.cpp:270: DB::getIdentifierName(DB::IAST const*) @ 0x00000000179bab12 5. /build/src/Parsers/ASTIdentifier_fwd.h:27: DB::create(DB::StorageFactory::Arguments const&) @ 0x000000001662c055 6. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000015d81ea2 7. /build/src/Interpreters/InterpreterCreateQuery.cpp:1945: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x00000000149009bb 8. /build/src/Interpreters/InterpreterCreateQuery.cpp:1743: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000148f9aa9 9. /build/src/Interpreters/InterpreterCreateQuery.cpp:2352: DB::InterpreterCreateQuery::execute() @ 0x0000000014905a41 10. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88dc9 11. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 12. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 13. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 14. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 15. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 16. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 17. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 18. ? @ 0x00007fbc6213eac3 19. ? @ 0x00007fbc621d0850 2025.07.28 12:00:04.732460 [ 17191 ] {} TCPHandler: Code: 223. DB::Exception: [price, spend] is not an identifier. (UNEXPECTED_AST_STRUCTURE), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x000000000a06b56b 4. /build/src/Parsers/ASTIdentifier.cpp:270: DB::getIdentifierName(DB::IAST const*) @ 0x00000000179bab12 5. /build/src/Parsers/ASTIdentifier_fwd.h:27: DB::create(DB::StorageFactory::Arguments const&) @ 0x000000001662c055 6. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000015d81ea2 7. /build/src/Interpreters/InterpreterCreateQuery.cpp:1945: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x00000000149009bb 8. /build/src/Interpreters/InterpreterCreateQuery.cpp:1743: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000148f9aa9 9. /build/src/Interpreters/InterpreterCreateQuery.cpp:2352: DB::InterpreterCreateQuery::execute() @ 0x0000000014905a41 10. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88dc9 11. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 12. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 13. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 14. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 15. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 16. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 17. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 18. ? @ 0x00007fbc6213eac3 19. ? @ 0x00007fbc621d0850 2025.07.28 12:00:05.504626 [ 3972 ] {} test_13.rmt2 (7f9b740d-015c-470e-8cc6-8ba33be0dc63): auto DB::StorageReplicatedMergeTree::processQueueEntry(ReplicatedMergeTreeQueue::SelectedEntryPtr)::(anonymous class)::operator()(LogEntryPtr &) const: Code: 86. DB::HTTPException: Received error from remote server http://146b4357c08d:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Ftest%2F01165%2Ftest_13%2Frmt%2Freplicas%2F1&part=20250728_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.6.10636.altinitytest (altinity build)) '. (RECEIVED_ERROR_FROM_REMOTE_IO_SERVER), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.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 const&, int&&, String const&, unsigned long&&, String const&) @ 0x000000000feda8d9 4. /build/src/IO/HTTPCommon.cpp:104: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x000000000feda6e2 5. /build/src/IO/HTTPCommon.cpp:93: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x000000000feda537 6. /build/src/IO/ReadWriteBufferFromHTTP.cpp:277: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x000000001184a4c4 7. /build/src/IO/ReadWriteBufferFromHTTP.cpp:285: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x000000001184a615 8. /build/src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x000000001184ae59 9. /build/src/IO/ReadWriteBufferFromHTTP.cpp:472: void std::__function::__policy_invoker::__call_impl[abi:se190107]>(std::__function::__policy_storage const*) @ 0x000000001184cedd 10. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001184858b 11. /build/src/IO/ReadWriteBufferFromHTTP.cpp:465: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x000000001184bf0b 12. /build/src/IO/ReadBuffer.h:60: DB::ReadBuffer::next() @ 0x000000000a148c7b 13. /build/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) @ 0x0000000011849fb2 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]>&)>&, 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&) @ 0x0000000011841980 15. /build/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) @ 0x000000001621208e 16. /build/src/Storages/StorageReplicatedMergeTree.cpp:5228: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl[abi:se190107] const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000015f9a5fe 17. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000015ed8bfd 18. /build/src/Storages/StorageReplicatedMergeTree.cpp:2514: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x0000000015ec9aab 19. /build/src/Storages/StorageReplicatedMergeTree.cpp:2349: DB::StorageReplicatedMergeTree::executeLogEntry(DB::ReplicatedMergeTreeLogEntry&) @ 0x0000000015eba91b 20. /build/src/Storages/StorageReplicatedMergeTree.cpp:3876: bool std::__function::__policy_invoker&)>::__call_impl[abi:se190107])::$_1, bool (std::shared_ptr&)>>(std::__function::__policy_storage const*, std::shared_ptr&) @ 0x0000000015f9837e 21. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000165d6fc3 22. /build/src/Storages/StorageReplicatedMergeTree.cpp:3872: DB::StorageReplicatedMergeTree::processQueueEntry(std::shared_ptr) @ 0x0000000015efc18a 23. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001624c1b2 24. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000162f9c70 25. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x00000000162fa55a 26. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc6653 27. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000000fccc4c3 28. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc3d92 29. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fcca080 30. ? @ 0x00007fbc6213eac3 31. ? @ 0x00007fbc621d0850 (version 25.3.6.10636.altinitytest (altinity build)) 2025.07.28 12:00:05.663359 [ 3971 ] {} test_13.rmt2 (7f9b740d-015c-470e-8cc6-8ba33be0dc63): auto DB::StorageReplicatedMergeTree::processQueueEntry(ReplicatedMergeTreeQueue::SelectedEntryPtr)::(anonymous class)::operator()(LogEntryPtr &) const: Code: 86. DB::HTTPException: Received error from remote server http://146b4357c08d:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Ftest%2F01165%2Ftest_13%2Frmt%2Freplicas%2F1&part=20250728_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.6.10636.altinitytest (altinity build)) '. (RECEIVED_ERROR_FROM_REMOTE_IO_SERVER), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.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 const&, int&&, String const&, unsigned long&&, String const&) @ 0x000000000feda8d9 4. /build/src/IO/HTTPCommon.cpp:104: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x000000000feda6e2 5. /build/src/IO/HTTPCommon.cpp:93: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x000000000feda537 6. /build/src/IO/ReadWriteBufferFromHTTP.cpp:277: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x000000001184a4c4 7. /build/src/IO/ReadWriteBufferFromHTTP.cpp:285: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x000000001184a615 8. /build/src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x000000001184ae59 9. /build/src/IO/ReadWriteBufferFromHTTP.cpp:472: void std::__function::__policy_invoker::__call_impl[abi:se190107]>(std::__function::__policy_storage const*) @ 0x000000001184cedd 10. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001184858b 11. /build/src/IO/ReadWriteBufferFromHTTP.cpp:465: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x000000001184bf0b 12. /build/src/IO/ReadBuffer.h:60: DB::ReadBuffer::next() @ 0x000000000a148c7b 13. /build/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) @ 0x0000000011849fb2 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]>&)>&, 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&) @ 0x0000000011841980 15. /build/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) @ 0x000000001621208e 16. /build/src/Storages/StorageReplicatedMergeTree.cpp:5228: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl[abi:se190107] const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000015f9a5fe 17. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000015ed8bfd 18. /build/src/Storages/StorageReplicatedMergeTree.cpp:2514: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x0000000015ec9aab 19. /build/src/Storages/StorageReplicatedMergeTree.cpp:2349: DB::StorageReplicatedMergeTree::executeLogEntry(DB::ReplicatedMergeTreeLogEntry&) @ 0x0000000015eba91b 20. /build/src/Storages/StorageReplicatedMergeTree.cpp:3876: bool std::__function::__policy_invoker&)>::__call_impl[abi:se190107])::$_1, bool (std::shared_ptr&)>>(std::__function::__policy_storage const*, std::shared_ptr&) @ 0x0000000015f9837e 21. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000165d6fc3 22. /build/src/Storages/StorageReplicatedMergeTree.cpp:3872: DB::StorageReplicatedMergeTree::processQueueEntry(std::shared_ptr) @ 0x0000000015efc18a 23. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001624c1b2 24. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000162f9c70 25. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x00000000162fa55a 26. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc6653 27. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000000fccc4c3 28. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc3d92 29. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fcca080 30. ? @ 0x00007fbc6213eac3 31. ? @ 0x00007fbc621d0850 (version 25.3.6.10636.altinitytest (altinity build)) 2025.07.28 12:00:06.592806 [ 3960 ] {} test_13.rmt2 (7f9b740d-015c-470e-8cc6-8ba33be0dc63): auto DB::StorageReplicatedMergeTree::processQueueEntry(ReplicatedMergeTreeQueue::SelectedEntryPtr)::(anonymous class)::operator()(LogEntryPtr &) const: Code: 86. DB::HTTPException: Received error from remote server http://146b4357c08d:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Ftest%2F01165%2Ftest_13%2Frmt%2Freplicas%2F1&part=20250728_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.6.10636.altinitytest (altinity build)) '. (RECEIVED_ERROR_FROM_REMOTE_IO_SERVER), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.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 const&, int&&, String const&, unsigned long&&, String const&) @ 0x000000000feda8d9 4. /build/src/IO/HTTPCommon.cpp:104: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x000000000feda6e2 5. /build/src/IO/HTTPCommon.cpp:93: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x000000000feda537 6. /build/src/IO/ReadWriteBufferFromHTTP.cpp:277: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x000000001184a4c4 7. /build/src/IO/ReadWriteBufferFromHTTP.cpp:285: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x000000001184a615 8. /build/src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x000000001184ae59 9. /build/src/IO/ReadWriteBufferFromHTTP.cpp:472: void std::__function::__policy_invoker::__call_impl[abi:se190107]>(std::__function::__policy_storage const*) @ 0x000000001184cedd 10. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001184858b 11. /build/src/IO/ReadWriteBufferFromHTTP.cpp:465: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x000000001184bf0b 12. /build/src/IO/ReadBuffer.h:60: DB::ReadBuffer::next() @ 0x000000000a148c7b 13. /build/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) @ 0x0000000011849fb2 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]>&)>&, 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&) @ 0x0000000011841980 15. /build/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) @ 0x000000001621208e 16. /build/src/Storages/StorageReplicatedMergeTree.cpp:5228: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl[abi:se190107] const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000015f9a5fe 17. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000015ed8bfd 18. /build/src/Storages/StorageReplicatedMergeTree.cpp:2514: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x0000000015ec9aab 19. /build/src/Storages/StorageReplicatedMergeTree.cpp:2349: DB::StorageReplicatedMergeTree::executeLogEntry(DB::ReplicatedMergeTreeLogEntry&) @ 0x0000000015eba91b 20. /build/src/Storages/StorageReplicatedMergeTree.cpp:3876: bool std::__function::__policy_invoker&)>::__call_impl[abi:se190107])::$_1, bool (std::shared_ptr&)>>(std::__function::__policy_storage const*, std::shared_ptr&) @ 0x0000000015f9837e 21. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000165d6fc3 22. /build/src/Storages/StorageReplicatedMergeTree.cpp:3872: DB::StorageReplicatedMergeTree::processQueueEntry(std::shared_ptr) @ 0x0000000015efc18a 23. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001624c1b2 24. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000162f9c70 25. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x00000000162fa55a 26. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc6653 27. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000000fccc4c3 28. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc3d92 29. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fcca080 30. ? @ 0x00007fbc6213eac3 31. ? @ 0x00007fbc621d0850 (version 25.3.6.10636.altinitytest (altinity build)) 2025.07.28 12:00:07.148317 [ 17191 ] {a58c272a-cf88-42c6-928c-0217c44fd430} executeQuery: Code: 57. DB::Exception: Table test_hv2hfx9w.sparse_tuple already exists. (TABLE_ALREADY_EXISTS) (version 25.3.6.10636.altinitytest (altinity build)) (from [::1]:39470) (comment: 01780_column_sparse_tuple.sql) (query 14, line 27) (in query: CREATE TABLE sparse_tuple (`id` UInt64, `t` Tuple(a UInt64, b Tuple(u UInt32, s String))) ENGINE = MergeTree ORDER BY tuple() SETTINGS ratio_of_defaults_for_sparse_serialization = 0.5, index_granularity = 48663, min_bytes_for_wide_part = 777830203, replace_long_file_name_to_hash = false, max_file_name_length = 128, min_bytes_for_full_part_storage = 381699282, compact_parts_max_bytes_to_buffer = 238071820, compact_parts_max_granules_to_buffer = 84, compact_parts_merge_max_bytes_to_prefetch_part = 6986771, merge_max_block_size = 9917, old_parts_lifetime = 10., prefer_fetch_merged_part_size_threshold = 1, vertical_merge_algorithm_min_rows_to_activate = 614470, vertical_merge_algorithm_min_columns_to_activate = 100, min_merge_bytes_to_use_direct_io = 1, index_granularity_bytes = 11814836, use_const_adaptive_granularity = false, enable_index_granularity_compression = true, concurrent_part_removal_threshold = 60, 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 = 28960, primary_key_compress_block_size = 45968, 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. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000a06a8eb 4. /build/src/Interpreters/InterpreterCreateQuery.cpp:1824: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x0000000014901d53 5. /build/src/Interpreters/InterpreterCreateQuery.cpp:1743: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000148f9aa9 6. /build/src/Interpreters/InterpreterCreateQuery.cpp:2352: DB::InterpreterCreateQuery::execute() @ 0x0000000014905a41 7. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88dc9 8. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 9. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 10. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 11. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 12. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 13. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 14. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 15. ? @ 0x00007fbc6213eac3 16. ? @ 0x00007fbc621d0850 2025.07.28 12:00:07.159513 [ 17191 ] {} TCPHandler: Code: 57. DB::Exception: Table test_hv2hfx9w.sparse_tuple already exists. (TABLE_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000a06a8eb 4. /build/src/Interpreters/InterpreterCreateQuery.cpp:1824: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x0000000014901d53 5. /build/src/Interpreters/InterpreterCreateQuery.cpp:1743: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000148f9aa9 6. /build/src/Interpreters/InterpreterCreateQuery.cpp:2352: DB::InterpreterCreateQuery::execute() @ 0x0000000014905a41 7. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88dc9 8. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 9. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 10. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 11. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 12. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 13. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 14. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 15. ? @ 0x00007fbc6213eac3 16. ? @ 0x00007fbc621d0850 2025.07.28 12:00:07.493392 [ 3966 ] {} test_13.rmt2 (7f9b740d-015c-470e-8cc6-8ba33be0dc63): auto DB::StorageReplicatedMergeTree::processQueueEntry(ReplicatedMergeTreeQueue::SelectedEntryPtr)::(anonymous class)::operator()(LogEntryPtr &) const: Code: 86. DB::HTTPException: Received error from remote server http://146b4357c08d:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Ftest%2F01165%2Ftest_13%2Frmt%2Freplicas%2F1&part=20250728_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.6.10636.altinitytest (altinity build)) '. (RECEIVED_ERROR_FROM_REMOTE_IO_SERVER), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.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 const&, int&&, String const&, unsigned long&&, String const&) @ 0x000000000feda8d9 4. /build/src/IO/HTTPCommon.cpp:104: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x000000000feda6e2 5. /build/src/IO/HTTPCommon.cpp:93: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x000000000feda537 6. /build/src/IO/ReadWriteBufferFromHTTP.cpp:277: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x000000001184a4c4 7. /build/src/IO/ReadWriteBufferFromHTTP.cpp:285: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x000000001184a615 8. /build/src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x000000001184ae59 9. /build/src/IO/ReadWriteBufferFromHTTP.cpp:472: void std::__function::__policy_invoker::__call_impl[abi:se190107]>(std::__function::__policy_storage const*) @ 0x000000001184cedd 10. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001184858b 11. /build/src/IO/ReadWriteBufferFromHTTP.cpp:465: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x000000001184bf0b 12. /build/src/IO/ReadBuffer.h:60: DB::ReadBuffer::next() @ 0x000000000a148c7b 13. /build/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) @ 0x0000000011849fb2 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]>&)>&, 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&) @ 0x0000000011841980 15. /build/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) @ 0x000000001621208e 16. /build/src/Storages/StorageReplicatedMergeTree.cpp:5228: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl[abi:se190107] const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000015f9a5fe 17. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000015ed8bfd 18. /build/src/Storages/StorageReplicatedMergeTree.cpp:2514: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x0000000015ec9aab 19. /build/src/Storages/StorageReplicatedMergeTree.cpp:2349: DB::StorageReplicatedMergeTree::executeLogEntry(DB::ReplicatedMergeTreeLogEntry&) @ 0x0000000015eba91b 20. /build/src/Storages/StorageReplicatedMergeTree.cpp:3876: bool std::__function::__policy_invoker&)>::__call_impl[abi:se190107])::$_1, bool (std::shared_ptr&)>>(std::__function::__policy_storage const*, std::shared_ptr&) @ 0x0000000015f9837e 21. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000165d6fc3 22. /build/src/Storages/StorageReplicatedMergeTree.cpp:3872: DB::StorageReplicatedMergeTree::processQueueEntry(std::shared_ptr) @ 0x0000000015efc18a 23. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001624c1b2 24. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000162f9c70 25. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x00000000162fa55a 26. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc6653 27. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000000fccc4c3 28. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc3d92 29. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fcca080 30. ? @ 0x00007fbc6213eac3 31. ? @ 0x00007fbc621d0850 (version 25.3.6.10636.altinitytest (altinity build)) 2025.07.28 12:00:07.674540 [ 17207 ] {2c03b2fb-a9ce-4923-8522-dd9a3dc6aa52} 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.6.10636.altinitytest (altinity build)) (from [::1]:39514) (comment: 01825_new_type_json_3.gen.sql) (query 4, line 10) (in query: CREATE TABLE t_json_3 (`id` UInt64, `data` JSON) ENGINE = ReplicatedMergeTree('/clickhouse/tables/{database}/test_01825_3/t_json_3', 'r1') ORDER BY tuple() SETTINGS index_granularity = 47209, min_bytes_for_wide_part = 906381449, ratio_of_defaults_for_sparse_serialization = 1., replace_long_file_name_to_hash = false, max_file_name_length = 87, min_bytes_for_full_part_storage = 24078931, compact_parts_max_bytes_to_buffer = 514810604, compact_parts_max_granules_to_buffer = 256, compact_parts_merge_max_bytes_to_prefetch_part = 21444175, merge_max_block_size = 20029, old_parts_lifetime = 441., 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 = 7112142667, index_granularity_bytes = 926033, use_const_adaptive_granularity = true, enable_index_granularity_compression = true, concurrent_part_removal_threshold = 99, 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 = 74811, primary_key_compress_block_size = 88522, 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. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000000a074fcb 4. /build/src/Databases/DatabaseReplicated.cpp:959: DB::DatabaseReplicated::checkTableEngine(DB::ASTCreateQuery const&, DB::ASTStorage&, std::shared_ptr) const @ 0x0000000013d9cf56 5. /build/src/Databases/DatabaseReplicated.cpp:1083: DB::DatabaseReplicated::checkQueryValid(std::shared_ptr const&, std::shared_ptr) const @ 0x0000000013d9ebb5 6. /build/src/Databases/DatabaseReplicated.cpp:1130: DB::DatabaseReplicated::tryEnqueueReplicatedDDL(std::shared_ptr const&, std::shared_ptr, DB::QueryFlags) @ 0x0000000013d9f10b 7. /build/src/Interpreters/InterpreterCreateQuery.cpp:1723: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000148f96f8 8. /build/src/Interpreters/InterpreterCreateQuery.cpp:2352: DB::InterpreterCreateQuery::execute() @ 0x0000000014905a41 9. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88dc9 10. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 11. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 12. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 13. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 14. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 16. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 17. ? @ 0x00007fbc6213eac3 18. ? @ 0x00007fbc621d0850 2025.07.28 12:00:07.738685 [ 17207 ] {} 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. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000000a074fcb 4. /build/src/Databases/DatabaseReplicated.cpp:959: DB::DatabaseReplicated::checkTableEngine(DB::ASTCreateQuery const&, DB::ASTStorage&, std::shared_ptr) const @ 0x0000000013d9cf56 5. /build/src/Databases/DatabaseReplicated.cpp:1083: DB::DatabaseReplicated::checkQueryValid(std::shared_ptr const&, std::shared_ptr) const @ 0x0000000013d9ebb5 6. /build/src/Databases/DatabaseReplicated.cpp:1130: DB::DatabaseReplicated::tryEnqueueReplicatedDDL(std::shared_ptr const&, std::shared_ptr, DB::QueryFlags) @ 0x0000000013d9f10b 7. /build/src/Interpreters/InterpreterCreateQuery.cpp:1723: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000148f96f8 8. /build/src/Interpreters/InterpreterCreateQuery.cpp:2352: DB::InterpreterCreateQuery::execute() @ 0x0000000014905a41 9. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88dc9 10. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 11. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 12. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 13. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 14. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 16. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 17. ? @ 0x00007fbc6213eac3 18. ? @ 0x00007fbc621d0850 2025.07.28 12:00:08.031786 [ 3962 ] {} test_13.rmt2 (7f9b740d-015c-470e-8cc6-8ba33be0dc63): auto DB::StorageReplicatedMergeTree::processQueueEntry(ReplicatedMergeTreeQueue::SelectedEntryPtr)::(anonymous class)::operator()(LogEntryPtr &) const: Code: 86. DB::HTTPException: Received error from remote server http://146b4357c08d:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Ftest%2F01165%2Ftest_13%2Frmt%2Freplicas%2F1&part=20250728_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.6.10636.altinitytest (altinity build)) '. (RECEIVED_ERROR_FROM_REMOTE_IO_SERVER), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.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 const&, int&&, String const&, unsigned long&&, String const&) @ 0x000000000feda8d9 4. /build/src/IO/HTTPCommon.cpp:104: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x000000000feda6e2 5. /build/src/IO/HTTPCommon.cpp:93: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x000000000feda537 6. /build/src/IO/ReadWriteBufferFromHTTP.cpp:277: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x000000001184a4c4 7. /build/src/IO/ReadWriteBufferFromHTTP.cpp:285: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x000000001184a615 8. /build/src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x000000001184ae59 9. /build/src/IO/ReadWriteBufferFromHTTP.cpp:472: void std::__function::__policy_invoker::__call_impl[abi:se190107]>(std::__function::__policy_storage const*) @ 0x000000001184cedd 10. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001184858b 11. /build/src/IO/ReadWriteBufferFromHTTP.cpp:465: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x000000001184bf0b 12. /build/src/IO/ReadBuffer.h:60: DB::ReadBuffer::next() @ 0x000000000a148c7b 13. /build/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) @ 0x0000000011849fb2 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]>&)>&, 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&) @ 0x0000000011841980 15. /build/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) @ 0x000000001621208e 16. /build/src/Storages/StorageReplicatedMergeTree.cpp:5228: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl[abi:se190107] const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000015f9a5fe 17. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000015ed8bfd 18. /build/src/Storages/StorageReplicatedMergeTree.cpp:2514: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x0000000015ec9aab 19. /build/src/Storages/StorageReplicatedMergeTree.cpp:2349: DB::StorageReplicatedMergeTree::executeLogEntry(DB::ReplicatedMergeTreeLogEntry&) @ 0x0000000015eba91b 20. /build/src/Storages/StorageReplicatedMergeTree.cpp:3876: bool std::__function::__policy_invoker&)>::__call_impl[abi:se190107])::$_1, bool (std::shared_ptr&)>>(std::__function::__policy_storage const*, std::shared_ptr&) @ 0x0000000015f9837e 21. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000165d6fc3 22. /build/src/Storages/StorageReplicatedMergeTree.cpp:3872: DB::StorageReplicatedMergeTree::processQueueEntry(std::shared_ptr) @ 0x0000000015efc18a 23. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001624c1b2 24. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000162f9c70 25. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x00000000162fa55a 26. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc6653 27. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000000fccc4c3 28. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc3d92 29. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fcca080 30. ? @ 0x00007fbc6213eac3 31. ? @ 0x00007fbc621d0850 (version 25.3.6.10636.altinitytest (altinity build)) 2025.07.28 12:00:08.353677 [ 17207 ] {ce61c1c7-4f8b-4922-9e42-8d18694b1b0a} executeQuery: Code: 57. DB::Exception: Table test_5.tab already exists. (TABLE_ALREADY_EXISTS) (version 25.3.6.10636.altinitytest (altinity build)) (from 0.0.0.0:0) (comment: 02915_analyzer_fuzz_6.sql) (in query: /* ddl_entry=query-0000000123 */ CREATE TABLE test_5.tab UUID '9111f591-4294-4816-b987-0f8862c5361c' (`x` LowCardinality(Nullable(Float64))) ENGINE = MergeTree ORDER BY x SETTINGS allow_nullable_key = 1, index_granularity = 33548, min_bytes_for_wide_part = 655544688, 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 = 536870912, compact_parts_max_bytes_to_buffer = 168162733, compact_parts_max_granules_to_buffer = 91, compact_parts_merge_max_bytes_to_prefetch_part = 32127952, merge_max_block_size = 19376, old_parts_lifetime = 168., prefer_fetch_merged_part_size_threshold = 10737418240, vertical_merge_algorithm_min_rows_to_activate = 1000000, vertical_merge_algorithm_min_columns_to_activate = 32, min_merge_bytes_to_use_direct_io = 3474966623, index_granularity_bytes = 17541023, use_const_adaptive_granularity = false, enable_index_granularity_compression = true, concurrent_part_removal_threshold = 63, 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 = 67141, primary_key_compress_block_size = 28189, 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. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000a06a8eb 4. /build/src/Interpreters/InterpreterCreateQuery.cpp:1824: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x0000000014901d53 5. /build/src/Interpreters/InterpreterCreateQuery.cpp:1743: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000148f9aa9 6. /build/src/Interpreters/InterpreterCreateQuery.cpp:2352: DB::InterpreterCreateQuery::execute() @ 0x0000000014905a41 7. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88dc9 8. /build/src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x0000000014c8ca7b 9. /build/src/Interpreters/DDLWorker.cpp:510: DB::DDLWorker::tryExecuteQuery(DB::DDLTaskBase&, std::shared_ptr const&, bool) @ 0x00000000144dab9e 10. /build/src/Interpreters/DDLWorker.cpp:675: DB::DDLWorker::processTask(DB::DDLTaskBase&, std::shared_ptr const&, bool) @ 0x00000000144d8ffe 11. /build/src/Databases/DatabaseReplicatedWorker.cpp:372: DB::DatabaseReplicatedDDLWorker::tryEnqueueAndExecuteEntry(DB::DDLLogEntry&, std::shared_ptr, bool) @ 0x0000000013dc29ab 12. /build/src/Databases/DatabaseReplicated.cpp:1139: DB::DatabaseReplicated::tryEnqueueReplicatedDDL(std::shared_ptr const&, std::shared_ptr, DB::QueryFlags) @ 0x0000000013d9f73c 13. /build/src/Interpreters/InterpreterCreateQuery.cpp:1723: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000148f96f8 14. /build/src/Interpreters/InterpreterCreateQuery.cpp:2352: DB::InterpreterCreateQuery::execute() @ 0x0000000014905a41 15. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88dc9 16. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 17. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 18. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 19. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 20. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 21. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 22. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 23. ? @ 0x00007fbc6213eac3 24. ? @ 0x00007fbc621d0850 2025.07.28 12:00:08.383558 [ 17207 ] {ce61c1c7-4f8b-4922-9e42-8d18694b1b0a} executeQuery: Code: 57. DB::Exception: Table test_5.tab already exists. (TABLE_ALREADY_EXISTS) (version 25.3.6.10636.altinitytest (altinity build)) (from [::1]:39542) (comment: 02915_analyzer_fuzz_6.sql) (query 3, line 4) (in query: CREATE TABLE tab (`x` LowCardinality(Nullable(Float64))) ENGINE = MergeTree ORDER BY x SETTINGS allow_nullable_key = 1, index_granularity = 33548, min_bytes_for_wide_part = 655544688, 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 = 536870912, compact_parts_max_bytes_to_buffer = 168162733, compact_parts_max_granules_to_buffer = 91, compact_parts_merge_max_bytes_to_prefetch_part = 32127952, merge_max_block_size = 19376, old_parts_lifetime = 168., prefer_fetch_merged_part_size_threshold = 10737418240, vertical_merge_algorithm_min_rows_to_activate = 1000000, vertical_merge_algorithm_min_columns_to_activate = 32, min_merge_bytes_to_use_direct_io = 3474966623, index_granularity_bytes = 17541023, use_const_adaptive_granularity = false, enable_index_granularity_compression = true, concurrent_part_removal_threshold = 63, 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 = 67141, primary_key_compress_block_size = 28189, 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. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000a06a8eb 4. /build/src/Interpreters/InterpreterCreateQuery.cpp:1824: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x0000000014901d53 5. /build/src/Interpreters/InterpreterCreateQuery.cpp:1743: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000148f9aa9 6. /build/src/Interpreters/InterpreterCreateQuery.cpp:2352: DB::InterpreterCreateQuery::execute() @ 0x0000000014905a41 7. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88dc9 8. /build/src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x0000000014c8ca7b 9. /build/src/Interpreters/DDLWorker.cpp:510: DB::DDLWorker::tryExecuteQuery(DB::DDLTaskBase&, std::shared_ptr const&, bool) @ 0x00000000144dab9e 10. /build/src/Interpreters/DDLWorker.cpp:675: DB::DDLWorker::processTask(DB::DDLTaskBase&, std::shared_ptr const&, bool) @ 0x00000000144d8ffe 11. /build/src/Databases/DatabaseReplicatedWorker.cpp:372: DB::DatabaseReplicatedDDLWorker::tryEnqueueAndExecuteEntry(DB::DDLLogEntry&, std::shared_ptr, bool) @ 0x0000000013dc29ab 12. /build/src/Databases/DatabaseReplicated.cpp:1139: DB::DatabaseReplicated::tryEnqueueReplicatedDDL(std::shared_ptr const&, std::shared_ptr, DB::QueryFlags) @ 0x0000000013d9f73c 13. /build/src/Interpreters/InterpreterCreateQuery.cpp:1723: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000148f96f8 14. /build/src/Interpreters/InterpreterCreateQuery.cpp:2352: DB::InterpreterCreateQuery::execute() @ 0x0000000014905a41 15. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88dc9 16. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 17. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 18. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 19. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 20. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 21. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 22. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 23. ? @ 0x00007fbc6213eac3 24. ? @ 0x00007fbc621d0850 2025.07.28 12:00:08.400025 [ 17207 ] {} TCPHandler: Code: 57. DB::Exception: Table test_5.tab already exists. (TABLE_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000a06a8eb 4. /build/src/Interpreters/InterpreterCreateQuery.cpp:1824: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x0000000014901d53 5. /build/src/Interpreters/InterpreterCreateQuery.cpp:1743: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000148f9aa9 6. /build/src/Interpreters/InterpreterCreateQuery.cpp:2352: DB::InterpreterCreateQuery::execute() @ 0x0000000014905a41 7. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88dc9 8. /build/src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x0000000014c8ca7b 9. /build/src/Interpreters/DDLWorker.cpp:510: DB::DDLWorker::tryExecuteQuery(DB::DDLTaskBase&, std::shared_ptr const&, bool) @ 0x00000000144dab9e 10. /build/src/Interpreters/DDLWorker.cpp:675: DB::DDLWorker::processTask(DB::DDLTaskBase&, std::shared_ptr const&, bool) @ 0x00000000144d8ffe 11. /build/src/Databases/DatabaseReplicatedWorker.cpp:372: DB::DatabaseReplicatedDDLWorker::tryEnqueueAndExecuteEntry(DB::DDLLogEntry&, std::shared_ptr, bool) @ 0x0000000013dc29ab 12. /build/src/Databases/DatabaseReplicated.cpp:1139: DB::DatabaseReplicated::tryEnqueueReplicatedDDL(std::shared_ptr const&, std::shared_ptr, DB::QueryFlags) @ 0x0000000013d9f73c 13. /build/src/Interpreters/InterpreterCreateQuery.cpp:1723: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000148f96f8 14. /build/src/Interpreters/InterpreterCreateQuery.cpp:2352: DB::InterpreterCreateQuery::execute() @ 0x0000000014905a41 15. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88dc9 16. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 17. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 18. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 19. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 20. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 21. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 22. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 23. ? @ 0x00007fbc6213eac3 24. ? @ 0x00007fbc621d0850 2025.07.28 12:00:08.685400 [ 3963 ] {} test_13.rmt2 (7f9b740d-015c-470e-8cc6-8ba33be0dc63): auto DB::StorageReplicatedMergeTree::processQueueEntry(ReplicatedMergeTreeQueue::SelectedEntryPtr)::(anonymous class)::operator()(LogEntryPtr &) const: Code: 86. DB::HTTPException: Received error from remote server http://146b4357c08d:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Ftest%2F01165%2Ftest_13%2Frmt%2Freplicas%2F1&part=20250728_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.6.10636.altinitytest (altinity build)) '. (RECEIVED_ERROR_FROM_REMOTE_IO_SERVER), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.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 const&, int&&, String const&, unsigned long&&, String const&) @ 0x000000000feda8d9 4. /build/src/IO/HTTPCommon.cpp:104: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x000000000feda6e2 5. /build/src/IO/HTTPCommon.cpp:93: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x000000000feda537 6. /build/src/IO/ReadWriteBufferFromHTTP.cpp:277: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x000000001184a4c4 7. /build/src/IO/ReadWriteBufferFromHTTP.cpp:285: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x000000001184a615 8. /build/src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x000000001184ae59 9. /build/src/IO/ReadWriteBufferFromHTTP.cpp:472: void std::__function::__policy_invoker::__call_impl[abi:se190107]>(std::__function::__policy_storage const*) @ 0x000000001184cedd 10. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001184858b 11. /build/src/IO/ReadWriteBufferFromHTTP.cpp:465: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x000000001184bf0b 12. /build/src/IO/ReadBuffer.h:60: DB::ReadBuffer::next() @ 0x000000000a148c7b 13. /build/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) @ 0x0000000011849fb2 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]>&)>&, 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&) @ 0x0000000011841980 15. /build/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) @ 0x000000001621208e 16. /build/src/Storages/StorageReplicatedMergeTree.cpp:5228: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl[abi:se190107] const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000015f9a5fe 17. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000015ed8bfd 18. /build/src/Storages/StorageReplicatedMergeTree.cpp:2514: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x0000000015ec9aab 19. /build/src/Storages/StorageReplicatedMergeTree.cpp:2349: DB::StorageReplicatedMergeTree::executeLogEntry(DB::ReplicatedMergeTreeLogEntry&) @ 0x0000000015eba91b 20. /build/src/Storages/StorageReplicatedMergeTree.cpp:3876: bool std::__function::__policy_invoker&)>::__call_impl[abi:se190107])::$_1, bool (std::shared_ptr&)>>(std::__function::__policy_storage const*, std::shared_ptr&) @ 0x0000000015f9837e 21. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000165d6fc3 22. /build/src/Storages/StorageReplicatedMergeTree.cpp:3872: DB::StorageReplicatedMergeTree::processQueueEntry(std::shared_ptr) @ 0x0000000015efc18a 23. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001624c1b2 24. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000162f9c70 25. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x00000000162fa55a 26. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc6653 27. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000000fccc4c3 28. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc3d92 29. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fcca080 30. ? @ 0x00007fbc6213eac3 31. ? @ 0x00007fbc621d0850 (version 25.3.6.10636.altinitytest (altinity build)) 2025.07.28 12:00:09.515065 [ 3976 ] {} test_13.rmt2 (7f9b740d-015c-470e-8cc6-8ba33be0dc63): auto DB::StorageReplicatedMergeTree::processQueueEntry(ReplicatedMergeTreeQueue::SelectedEntryPtr)::(anonymous class)::operator()(LogEntryPtr &) const: Code: 86. DB::HTTPException: Received error from remote server http://146b4357c08d:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Ftest%2F01165%2Ftest_13%2Frmt%2Freplicas%2F1&part=20250728_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.6.10636.altinitytest (altinity build)) '. (RECEIVED_ERROR_FROM_REMOTE_IO_SERVER), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.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 const&, int&&, String const&, unsigned long&&, String const&) @ 0x000000000feda8d9 4. /build/src/IO/HTTPCommon.cpp:104: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x000000000feda6e2 5. /build/src/IO/HTTPCommon.cpp:93: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x000000000feda537 6. /build/src/IO/ReadWriteBufferFromHTTP.cpp:277: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x000000001184a4c4 7. /build/src/IO/ReadWriteBufferFromHTTP.cpp:285: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x000000001184a615 8. /build/src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x000000001184ae59 9. /build/src/IO/ReadWriteBufferFromHTTP.cpp:472: void std::__function::__policy_invoker::__call_impl[abi:se190107]>(std::__function::__policy_storage const*) @ 0x000000001184cedd 10. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001184858b 11. /build/src/IO/ReadWriteBufferFromHTTP.cpp:465: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x000000001184bf0b 12. /build/src/IO/ReadBuffer.h:60: DB::ReadBuffer::next() @ 0x000000000a148c7b 13. /build/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) @ 0x0000000011849fb2 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]>&)>&, 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&) @ 0x0000000011841980 15. /build/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) @ 0x000000001621208e 16. /build/src/Storages/StorageReplicatedMergeTree.cpp:5228: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl[abi:se190107] const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000015f9a5fe 17. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000015ed8bfd 18. /build/src/Storages/StorageReplicatedMergeTree.cpp:2514: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x0000000015ec9aab 19. /build/src/Storages/StorageReplicatedMergeTree.cpp:2349: DB::StorageReplicatedMergeTree::executeLogEntry(DB::ReplicatedMergeTreeLogEntry&) @ 0x0000000015eba91b 20. /build/src/Storages/StorageReplicatedMergeTree.cpp:3876: bool std::__function::__policy_invoker&)>::__call_impl[abi:se190107])::$_1, bool (std::shared_ptr&)>>(std::__function::__policy_storage const*, std::shared_ptr&) @ 0x0000000015f9837e 21. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000165d6fc3 22. /build/src/Storages/StorageReplicatedMergeTree.cpp:3872: DB::StorageReplicatedMergeTree::processQueueEntry(std::shared_ptr) @ 0x0000000015efc18a 23. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001624c1b2 24. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000162f9c70 25. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x00000000162fa55a 26. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc6653 27. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000000fccc4c3 28. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc3d92 29. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fcca080 30. ? @ 0x00007fbc6213eac3 31. ? @ 0x00007fbc621d0850 (version 25.3.6.10636.altinitytest (altinity build)) 2025.07.28 12:00:10.251525 [ 3977 ] {} test_13.rmt2 (7f9b740d-015c-470e-8cc6-8ba33be0dc63): auto DB::StorageReplicatedMergeTree::processQueueEntry(ReplicatedMergeTreeQueue::SelectedEntryPtr)::(anonymous class)::operator()(LogEntryPtr &) const: Code: 86. DB::HTTPException: Received error from remote server http://146b4357c08d:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Ftest%2F01165%2Ftest_13%2Frmt%2Freplicas%2F1&part=20250728_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.6.10636.altinitytest (altinity build)) '. (RECEIVED_ERROR_FROM_REMOTE_IO_SERVER), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.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 const&, int&&, String const&, unsigned long&&, String const&) @ 0x000000000feda8d9 4. /build/src/IO/HTTPCommon.cpp:104: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x000000000feda6e2 5. /build/src/IO/HTTPCommon.cpp:93: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x000000000feda537 6. /build/src/IO/ReadWriteBufferFromHTTP.cpp:277: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x000000001184a4c4 7. /build/src/IO/ReadWriteBufferFromHTTP.cpp:285: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x000000001184a615 8. /build/src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x000000001184ae59 9. /build/src/IO/ReadWriteBufferFromHTTP.cpp:472: void std::__function::__policy_invoker::__call_impl[abi:se190107]>(std::__function::__policy_storage const*) @ 0x000000001184cedd 10. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001184858b 11. /build/src/IO/ReadWriteBufferFromHTTP.cpp:465: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x000000001184bf0b 12. /build/src/IO/ReadBuffer.h:60: DB::ReadBuffer::next() @ 0x000000000a148c7b 13. /build/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) @ 0x0000000011849fb2 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]>&)>&, 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&) @ 0x0000000011841980 15. /build/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) @ 0x000000001621208e 16. /build/src/Storages/StorageReplicatedMergeTree.cpp:5228: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl[abi:se190107] const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000015f9a5fe 17. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000015ed8bfd 18. /build/src/Storages/StorageReplicatedMergeTree.cpp:2514: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x0000000015ec9aab 19. /build/src/Storages/StorageReplicatedMergeTree.cpp:2349: DB::StorageReplicatedMergeTree::executeLogEntry(DB::ReplicatedMergeTreeLogEntry&) @ 0x0000000015eba91b 20. /build/src/Storages/StorageReplicatedMergeTree.cpp:3876: bool std::__function::__policy_invoker&)>::__call_impl[abi:se190107])::$_1, bool (std::shared_ptr&)>>(std::__function::__policy_storage const*, std::shared_ptr&) @ 0x0000000015f9837e 21. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000165d6fc3 22. /build/src/Storages/StorageReplicatedMergeTree.cpp:3872: DB::StorageReplicatedMergeTree::processQueueEntry(std::shared_ptr) @ 0x0000000015efc18a 23. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001624c1b2 24. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000162f9c70 25. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x00000000162fa55a 26. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc6653 27. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000000fccc4c3 28. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc3d92 29. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fcca080 30. ? @ 0x00007fbc6213eac3 31. ? @ 0x00007fbc621d0850 (version 25.3.6.10636.altinitytest (altinity build)) 2025.07.28 12:00:11.201707 [ 3963 ] {} test_13.rmt2 (7f9b740d-015c-470e-8cc6-8ba33be0dc63): auto DB::StorageReplicatedMergeTree::processQueueEntry(ReplicatedMergeTreeQueue::SelectedEntryPtr)::(anonymous class)::operator()(LogEntryPtr &) const: Code: 86. DB::HTTPException: Received error from remote server http://146b4357c08d:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Ftest%2F01165%2Ftest_13%2Frmt%2Freplicas%2F1&part=20250728_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.6.10636.altinitytest (altinity build)) '. (RECEIVED_ERROR_FROM_REMOTE_IO_SERVER), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.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 const&, int&&, String const&, unsigned long&&, String const&) @ 0x000000000feda8d9 4. /build/src/IO/HTTPCommon.cpp:104: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x000000000feda6e2 5. /build/src/IO/HTTPCommon.cpp:93: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x000000000feda537 6. /build/src/IO/ReadWriteBufferFromHTTP.cpp:277: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x000000001184a4c4 7. /build/src/IO/ReadWriteBufferFromHTTP.cpp:285: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x000000001184a615 8. /build/src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x000000001184ae59 9. /build/src/IO/ReadWriteBufferFromHTTP.cpp:472: void std::__function::__policy_invoker::__call_impl[abi:se190107]>(std::__function::__policy_storage const*) @ 0x000000001184cedd 10. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001184858b 11. /build/src/IO/ReadWriteBufferFromHTTP.cpp:465: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x000000001184bf0b 12. /build/src/IO/ReadBuffer.h:60: DB::ReadBuffer::next() @ 0x000000000a148c7b 13. /build/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) @ 0x0000000011849fb2 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]>&)>&, 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&) @ 0x0000000011841980 15. /build/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) @ 0x000000001621208e 16. /build/src/Storages/StorageReplicatedMergeTree.cpp:5228: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl[abi:se190107] const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000015f9a5fe 17. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000015ed8bfd 18. /build/src/Storages/StorageReplicatedMergeTree.cpp:2514: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x0000000015ec9aab 19. /build/src/Storages/StorageReplicatedMergeTree.cpp:2349: DB::StorageReplicatedMergeTree::executeLogEntry(DB::ReplicatedMergeTreeLogEntry&) @ 0x0000000015eba91b 20. /build/src/Storages/StorageReplicatedMergeTree.cpp:3876: bool std::__function::__policy_invoker&)>::__call_impl[abi:se190107])::$_1, bool (std::shared_ptr&)>>(std::__function::__policy_storage const*, std::shared_ptr&) @ 0x0000000015f9837e 21. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000165d6fc3 22. /build/src/Storages/StorageReplicatedMergeTree.cpp:3872: DB::StorageReplicatedMergeTree::processQueueEntry(std::shared_ptr) @ 0x0000000015efc18a 23. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001624c1b2 24. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000162f9c70 25. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x00000000162fa55a 26. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc6653 27. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000000fccc4c3 28. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc3d92 29. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fcca080 30. ? @ 0x00007fbc6213eac3 31. ? @ 0x00007fbc621d0850 (version 25.3.6.10636.altinitytest (altinity build)) 2025.07.28 12:00:11.429611 [ 17203 ] {d9119c5e-f3bd-4b44-8859-e82f40063b4e} executeQuery: Code: 219. DB::Exception: New table appeared in database being dropped or detached. Try again. (DATABASE_NOT_EMPTY) (version 25.3.6.10636.altinitytest (altinity build)) (from [::1]:34904) (comment: 03073_analyzer_alias_as_column_name.sql) (in query: DROP DATABASE IF EXISTS test_a65ndryp SYNC ), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000000a074fcb 4. /build/src/Interpreters/DatabaseCatalog.cpp:608: DB::DatabaseCatalog::detachDatabase(std::shared_ptr, String const&, bool, bool) @ 0x00000000144f41b9 5. /build/src/Interpreters/InterpreterDropQuery.cpp:482: DB::InterpreterDropQuery::executeToDatabaseImpl(DB::ASTDropQuery const&, std::shared_ptr&, std::vector, DB::UUIDTag>, std::allocator, DB::UUIDTag>>>&) @ 0x00000000149179be 6. /build/src/Interpreters/InterpreterDropQuery.cpp:363: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x0000000014913988 7. /build/src/Interpreters/InterpreterDropQuery.cpp:99: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000014913142 8. /build/src/Interpreters/InterpreterDropQuery.cpp:72: DB::InterpreterDropQuery::execute() @ 0x0000000014912b65 9. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88dc9 10. /build/src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x0000000014c8ca7b 11. /build/src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000001686da12 12. /build/src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x0000000016870807 13. /build/src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x0000000016907e99 14. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 15. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 16. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 17. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 18. ? @ 0x00007fbc6213eac3 19. ? @ 0x00007fbc621d0850 2025.07.28 12:00:11.437180 [ 17203 ] {d9119c5e-f3bd-4b44-8859-e82f40063b4e} 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. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000000a074fcb 4. /build/src/Interpreters/DatabaseCatalog.cpp:608: DB::DatabaseCatalog::detachDatabase(std::shared_ptr, String const&, bool, bool) @ 0x00000000144f41b9 5. /build/src/Interpreters/InterpreterDropQuery.cpp:482: DB::InterpreterDropQuery::executeToDatabaseImpl(DB::ASTDropQuery const&, std::shared_ptr&, std::vector, DB::UUIDTag>, std::allocator, DB::UUIDTag>>>&) @ 0x00000000149179be 6. /build/src/Interpreters/InterpreterDropQuery.cpp:363: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x0000000014913988 7. /build/src/Interpreters/InterpreterDropQuery.cpp:99: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000014913142 8. /build/src/Interpreters/InterpreterDropQuery.cpp:72: DB::InterpreterDropQuery::execute() @ 0x0000000014912b65 9. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88dc9 10. /build/src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x0000000014c8ca7b 11. /build/src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000001686da12 12. /build/src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x0000000016870807 13. /build/src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x0000000016907e99 14. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 15. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 16. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 17. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 18. ? @ 0x00007fbc6213eac3 19. ? @ 0x00007fbc621d0850 (version 25.3.6.10636.altinitytest (altinity build)) 2025.07.28 12:00:12.066158 [ 3965 ] {} test_13.rmt2 (7f9b740d-015c-470e-8cc6-8ba33be0dc63): auto DB::StorageReplicatedMergeTree::processQueueEntry(ReplicatedMergeTreeQueue::SelectedEntryPtr)::(anonymous class)::operator()(LogEntryPtr &) const: Code: 86. DB::HTTPException: Received error from remote server http://146b4357c08d:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Ftest%2F01165%2Ftest_13%2Frmt%2Freplicas%2F1&part=20250728_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.6.10636.altinitytest (altinity build)) '. (RECEIVED_ERROR_FROM_REMOTE_IO_SERVER), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.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 const&, int&&, String const&, unsigned long&&, String const&) @ 0x000000000feda8d9 4. /build/src/IO/HTTPCommon.cpp:104: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x000000000feda6e2 5. /build/src/IO/HTTPCommon.cpp:93: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x000000000feda537 6. /build/src/IO/ReadWriteBufferFromHTTP.cpp:277: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x000000001184a4c4 7. /build/src/IO/ReadWriteBufferFromHTTP.cpp:285: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x000000001184a615 8. /build/src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x000000001184ae59 9. /build/src/IO/ReadWriteBufferFromHTTP.cpp:472: void std::__function::__policy_invoker::__call_impl[abi:se190107]>(std::__function::__policy_storage const*) @ 0x000000001184cedd 10. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001184858b 11. /build/src/IO/ReadWriteBufferFromHTTP.cpp:465: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x000000001184bf0b 12. /build/src/IO/ReadBuffer.h:60: DB::ReadBuffer::next() @ 0x000000000a148c7b 13. /build/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) @ 0x0000000011849fb2 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]>&)>&, 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&) @ 0x0000000011841980 15. /build/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) @ 0x000000001621208e 16. /build/src/Storages/StorageReplicatedMergeTree.cpp:5228: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl[abi:se190107] const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000015f9a5fe 17. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000015ed8bfd 18. /build/src/Storages/StorageReplicatedMergeTree.cpp:2514: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x0000000015ec9aab 19. /build/src/Storages/StorageReplicatedMergeTree.cpp:2349: DB::StorageReplicatedMergeTree::executeLogEntry(DB::ReplicatedMergeTreeLogEntry&) @ 0x0000000015eba91b 20. /build/src/Storages/StorageReplicatedMergeTree.cpp:3876: bool std::__function::__policy_invoker&)>::__call_impl[abi:se190107])::$_1, bool (std::shared_ptr&)>>(std::__function::__policy_storage const*, std::shared_ptr&) @ 0x0000000015f9837e 21. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000165d6fc3 22. /build/src/Storages/StorageReplicatedMergeTree.cpp:3872: DB::StorageReplicatedMergeTree::processQueueEntry(std::shared_ptr) @ 0x0000000015efc18a 23. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001624c1b2 24. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000162f9c70 25. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x00000000162fa55a 26. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc6653 27. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000000fccc4c3 28. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc3d92 29. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fcca080 30. ? @ 0x00007fbc6213eac3 31. ? @ 0x00007fbc621d0850 (version 25.3.6.10636.altinitytest (altinity build)) 2025.07.28 12:00:13.091919 [ 3961 ] {} test_13.rmt2 (7f9b740d-015c-470e-8cc6-8ba33be0dc63): auto DB::StorageReplicatedMergeTree::processQueueEntry(ReplicatedMergeTreeQueue::SelectedEntryPtr)::(anonymous class)::operator()(LogEntryPtr &) const: Code: 86. DB::HTTPException: Received error from remote server http://146b4357c08d:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Ftest%2F01165%2Ftest_13%2Frmt%2Freplicas%2F1&part=20250728_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.6.10636.altinitytest (altinity build)) '. (RECEIVED_ERROR_FROM_REMOTE_IO_SERVER), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.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 const&, int&&, String const&, unsigned long&&, String const&) @ 0x000000000feda8d9 4. /build/src/IO/HTTPCommon.cpp:104: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x000000000feda6e2 5. /build/src/IO/HTTPCommon.cpp:93: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x000000000feda537 6. /build/src/IO/ReadWriteBufferFromHTTP.cpp:277: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x000000001184a4c4 7. /build/src/IO/ReadWriteBufferFromHTTP.cpp:285: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x000000001184a615 8. /build/src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x000000001184ae59 9. /build/src/IO/ReadWriteBufferFromHTTP.cpp:472: void std::__function::__policy_invoker::__call_impl[abi:se190107]>(std::__function::__policy_storage const*) @ 0x000000001184cedd 10. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001184858b 11. /build/src/IO/ReadWriteBufferFromHTTP.cpp:465: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x000000001184bf0b 12. /build/src/IO/ReadBuffer.h:60: DB::ReadBuffer::next() @ 0x000000000a148c7b 13. /build/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) @ 0x0000000011849fb2 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]>&)>&, 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&) @ 0x0000000011841980 15. /build/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) @ 0x000000001621208e 16. /build/src/Storages/StorageReplicatedMergeTree.cpp:5228: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl[abi:se190107] const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000015f9a5fe 17. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000015ed8bfd 18. /build/src/Storages/StorageReplicatedMergeTree.cpp:2514: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x0000000015ec9aab 19. /build/src/Storages/StorageReplicatedMergeTree.cpp:2349: DB::StorageReplicatedMergeTree::executeLogEntry(DB::ReplicatedMergeTreeLogEntry&) @ 0x0000000015eba91b 20. /build/src/Storages/StorageReplicatedMergeTree.cpp:3876: bool std::__function::__policy_invoker&)>::__call_impl[abi:se190107])::$_1, bool (std::shared_ptr&)>>(std::__function::__policy_storage const*, std::shared_ptr&) @ 0x0000000015f9837e 21. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000165d6fc3 22. /build/src/Storages/StorageReplicatedMergeTree.cpp:3872: DB::StorageReplicatedMergeTree::processQueueEntry(std::shared_ptr) @ 0x0000000015efc18a 23. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001624c1b2 24. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000162f9c70 25. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x00000000162fa55a 26. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc6653 27. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000000fccc4c3 28. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc3d92 29. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fcca080 30. ? @ 0x00007fbc6213eac3 31. ? @ 0x00007fbc621d0850 (version 25.3.6.10636.altinitytest (altinity build)) 2025.07.28 12:00:13.229106 [ 17252 ] {c6c58861-11cf-414b-995e-d8f289424109} executeQuery: Code: 36. DB::Exception: Path of the custom local disk must be inside `/var/lib/clickhouse/disks/` directory: While processing disk(type = local, path = '/local/'). (BAD_ARGUMENTS) (version 25.3.6.10636.altinitytest (altinity build)) (from [::1]:33196) (comment: 02454_create_table_with_custom_disk.sh) (query 3, line 9) (in query: CREATE TABLE test (a Int32) ENGINE = MergeTree() order by tuple() SETTINGS disk = disk(type=local, path='/local/');), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x000000000a080b2b 4. /build/src/Disks/DiskFromAST.cpp:88: DB::getOrCreateCustomDisk(Poco::AutoPtr, String const&, std::shared_ptr, bool) @ 0x000000001650c9ed 5. /build/src/Disks/DiskFromAST.cpp:117: DB::DiskConfigurationFlattener::visit(std::shared_ptr&, DB::DiskConfigurationFlattener::Data&) @ 0x000000001650d55c 6. /build/src/Interpreters/InDepthNodeVisitor.h:71: DB::InDepthNodeVisitor>::doVisit(std::shared_ptr&) @ 0x000000001650d3d5 7. /build/src/Interpreters/InDepthNodeVisitor.h:61: DB::DiskFromAST::createCustomDisk(std::shared_ptr const&, std::shared_ptr, bool) @ 0x000000001650ccea 8. /build/src/Storages/MergeTree/MergeTreeSettings.cpp:398: DB::MergeTreeSettingsImpl::loadFromQuery(DB::ASTStorage&, std::shared_ptr, bool) @ 0x00000000164df189 9. /build/src/Storages/MergeTree/MergeTreeSettings.cpp:714: DB::MergeTreeSettings::loadFromQuery(DB::ASTStorage&, std::shared_ptr, bool) @ 0x00000000164e1a24 10. /build/src/Storages/MergeTree/registerStorageMergeTree.cpp:705: DB::create(DB::StorageFactory::Arguments const&) @ 0x000000001662dffe 11. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000015d81ea2 12. /build/src/Interpreters/InterpreterCreateQuery.cpp:1945: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x00000000149009bb 13. /build/src/Interpreters/InterpreterCreateQuery.cpp:1743: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000148f9aa9 14. /build/src/Interpreters/InterpreterCreateQuery.cpp:2352: DB::InterpreterCreateQuery::execute() @ 0x0000000014905a41 15. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88dc9 16. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 17. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 18. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 19. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 20. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 21. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 22. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 23. ? @ 0x00007fbc6213eac3 24. ? @ 0x00007fbc621d0850 2025.07.28 12:00:13.253148 [ 17252 ] {} TCPHandler: Code: 36. DB::Exception: Path of the custom local disk must be inside `/var/lib/clickhouse/disks/` directory: While processing disk(type = local, path = '/local/'). (BAD_ARGUMENTS), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x000000000a080b2b 4. /build/src/Disks/DiskFromAST.cpp:88: DB::getOrCreateCustomDisk(Poco::AutoPtr, String const&, std::shared_ptr, bool) @ 0x000000001650c9ed 5. /build/src/Disks/DiskFromAST.cpp:117: DB::DiskConfigurationFlattener::visit(std::shared_ptr&, DB::DiskConfigurationFlattener::Data&) @ 0x000000001650d55c 6. /build/src/Interpreters/InDepthNodeVisitor.h:71: DB::InDepthNodeVisitor>::doVisit(std::shared_ptr&) @ 0x000000001650d3d5 7. /build/src/Interpreters/InDepthNodeVisitor.h:61: DB::DiskFromAST::createCustomDisk(std::shared_ptr const&, std::shared_ptr, bool) @ 0x000000001650ccea 8. /build/src/Storages/MergeTree/MergeTreeSettings.cpp:398: DB::MergeTreeSettingsImpl::loadFromQuery(DB::ASTStorage&, std::shared_ptr, bool) @ 0x00000000164df189 9. /build/src/Storages/MergeTree/MergeTreeSettings.cpp:714: DB::MergeTreeSettings::loadFromQuery(DB::ASTStorage&, std::shared_ptr, bool) @ 0x00000000164e1a24 10. /build/src/Storages/MergeTree/registerStorageMergeTree.cpp:705: DB::create(DB::StorageFactory::Arguments const&) @ 0x000000001662dffe 11. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000015d81ea2 12. /build/src/Interpreters/InterpreterCreateQuery.cpp:1945: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x00000000149009bb 13. /build/src/Interpreters/InterpreterCreateQuery.cpp:1743: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000148f9aa9 14. /build/src/Interpreters/InterpreterCreateQuery.cpp:2352: DB::InterpreterCreateQuery::execute() @ 0x0000000014905a41 15. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88dc9 16. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 17. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 18. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 19. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 20. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 21. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 22. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 23. ? @ 0x00007fbc6213eac3 24. ? @ 0x00007fbc621d0850 2025.07.28 12:00:13.415367 [ 3960 ] {} test_13.rmt2 (7f9b740d-015c-470e-8cc6-8ba33be0dc63): auto DB::StorageReplicatedMergeTree::processQueueEntry(ReplicatedMergeTreeQueue::SelectedEntryPtr)::(anonymous class)::operator()(LogEntryPtr &) const: Code: 86. DB::HTTPException: Received error from remote server http://146b4357c08d:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Ftest%2F01165%2Ftest_13%2Frmt%2Freplicas%2F1&part=20250728_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.6.10636.altinitytest (altinity build)) '. (RECEIVED_ERROR_FROM_REMOTE_IO_SERVER), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.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 const&, int&&, String const&, unsigned long&&, String const&) @ 0x000000000feda8d9 4. /build/src/IO/HTTPCommon.cpp:104: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x000000000feda6e2 5. /build/src/IO/HTTPCommon.cpp:93: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x000000000feda537 6. /build/src/IO/ReadWriteBufferFromHTTP.cpp:277: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x000000001184a4c4 7. /build/src/IO/ReadWriteBufferFromHTTP.cpp:285: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x000000001184a615 8. /build/src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x000000001184ae59 9. /build/src/IO/ReadWriteBufferFromHTTP.cpp:472: void std::__function::__policy_invoker::__call_impl[abi:se190107]>(std::__function::__policy_storage const*) @ 0x000000001184cedd 10. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001184858b 11. /build/src/IO/ReadWriteBufferFromHTTP.cpp:465: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x000000001184bf0b 12. /build/src/IO/ReadBuffer.h:60: DB::ReadBuffer::next() @ 0x000000000a148c7b 13. /build/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) @ 0x0000000011849fb2 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]>&)>&, 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&) @ 0x0000000011841980 15. /build/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) @ 0x000000001621208e 16. /build/src/Storages/StorageReplicatedMergeTree.cpp:5228: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl[abi:se190107] const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000015f9a5fe 17. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000015ed8bfd 18. /build/src/Storages/StorageReplicatedMergeTree.cpp:2514: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x0000000015ec9aab 19. /build/src/Storages/StorageReplicatedMergeTree.cpp:2349: DB::StorageReplicatedMergeTree::executeLogEntry(DB::ReplicatedMergeTreeLogEntry&) @ 0x0000000015eba91b 20. /build/src/Storages/StorageReplicatedMergeTree.cpp:3876: bool std::__function::__policy_invoker&)>::__call_impl[abi:se190107])::$_1, bool (std::shared_ptr&)>>(std::__function::__policy_storage const*, std::shared_ptr&) @ 0x0000000015f9837e 21. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000165d6fc3 22. /build/src/Storages/StorageReplicatedMergeTree.cpp:3872: DB::StorageReplicatedMergeTree::processQueueEntry(std::shared_ptr) @ 0x0000000015efc18a 23. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001624c1b2 24. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000162f9c70 25. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x00000000162fa55a 26. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc6653 27. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000000fccc4c3 28. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc3d92 29. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fcca080 30. ? @ 0x00007fbc6213eac3 31. ? @ 0x00007fbc621d0850 (version 25.3.6.10636.altinitytest (altinity build)) 2025.07.28 12:00:13.918040 [ 3974 ] {} test_13.rmt2 (7f9b740d-015c-470e-8cc6-8ba33be0dc63): auto DB::StorageReplicatedMergeTree::processQueueEntry(ReplicatedMergeTreeQueue::SelectedEntryPtr)::(anonymous class)::operator()(LogEntryPtr &) const: Code: 86. DB::HTTPException: Received error from remote server http://146b4357c08d:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Ftest%2F01165%2Ftest_13%2Frmt%2Freplicas%2F1&part=20250728_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.6.10636.altinitytest (altinity build)) '. (RECEIVED_ERROR_FROM_REMOTE_IO_SERVER), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.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 const&, int&&, String const&, unsigned long&&, String const&) @ 0x000000000feda8d9 4. /build/src/IO/HTTPCommon.cpp:104: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x000000000feda6e2 5. /build/src/IO/HTTPCommon.cpp:93: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x000000000feda537 6. /build/src/IO/ReadWriteBufferFromHTTP.cpp:277: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x000000001184a4c4 7. /build/src/IO/ReadWriteBufferFromHTTP.cpp:285: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x000000001184a615 8. /build/src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x000000001184ae59 9. /build/src/IO/ReadWriteBufferFromHTTP.cpp:472: void std::__function::__policy_invoker::__call_impl[abi:se190107]>(std::__function::__policy_storage const*) @ 0x000000001184cedd 10. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001184858b 11. /build/src/IO/ReadWriteBufferFromHTTP.cpp:465: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x000000001184bf0b 12. /build/src/IO/ReadBuffer.h:60: DB::ReadBuffer::next() @ 0x000000000a148c7b 13. /build/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) @ 0x0000000011849fb2 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]>&)>&, 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&) @ 0x0000000011841980 15. /build/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) @ 0x000000001621208e 16. /build/src/Storages/StorageReplicatedMergeTree.cpp:5228: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl[abi:se190107] const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000015f9a5fe 17. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000015ed8bfd 18. /build/src/Storages/StorageReplicatedMergeTree.cpp:2514: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x0000000015ec9aab 19. /build/src/Storages/StorageReplicatedMergeTree.cpp:2349: DB::StorageReplicatedMergeTree::executeLogEntry(DB::ReplicatedMergeTreeLogEntry&) @ 0x0000000015eba91b 20. /build/src/Storages/StorageReplicatedMergeTree.cpp:3876: bool std::__function::__policy_invoker&)>::__call_impl[abi:se190107])::$_1, bool (std::shared_ptr&)>>(std::__function::__policy_storage const*, std::shared_ptr&) @ 0x0000000015f9837e 21. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000165d6fc3 22. /build/src/Storages/StorageReplicatedMergeTree.cpp:3872: DB::StorageReplicatedMergeTree::processQueueEntry(std::shared_ptr) @ 0x0000000015efc18a 23. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001624c1b2 24. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000162f9c70 25. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x00000000162fa55a 26. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc6653 27. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000000fccc4c3 28. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc3d92 29. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fcca080 30. ? @ 0x00007fbc6213eac3 31. ? @ 0x00007fbc621d0850 (version 25.3.6.10636.altinitytest (altinity build)) 2025.07.28 12:00:14.220773 [ 3967 ] {} test_13.rmt2 (7f9b740d-015c-470e-8cc6-8ba33be0dc63): auto DB::StorageReplicatedMergeTree::processQueueEntry(ReplicatedMergeTreeQueue::SelectedEntryPtr)::(anonymous class)::operator()(LogEntryPtr &) const: Code: 86. DB::HTTPException: Received error from remote server http://146b4357c08d:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Ftest%2F01165%2Ftest_13%2Frmt%2Freplicas%2F1&part=20250728_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.6.10636.altinitytest (altinity build)) '. (RECEIVED_ERROR_FROM_REMOTE_IO_SERVER), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.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 const&, int&&, String const&, unsigned long&&, String const&) @ 0x000000000feda8d9 4. /build/src/IO/HTTPCommon.cpp:104: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x000000000feda6e2 5. /build/src/IO/HTTPCommon.cpp:93: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x000000000feda537 6. /build/src/IO/ReadWriteBufferFromHTTP.cpp:277: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x000000001184a4c4 7. /build/src/IO/ReadWriteBufferFromHTTP.cpp:285: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x000000001184a615 8. /build/src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x000000001184ae59 9. /build/src/IO/ReadWriteBufferFromHTTP.cpp:472: void std::__function::__policy_invoker::__call_impl[abi:se190107]>(std::__function::__policy_storage const*) @ 0x000000001184cedd 10. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001184858b 11. /build/src/IO/ReadWriteBufferFromHTTP.cpp:465: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x000000001184bf0b 12. /build/src/IO/ReadBuffer.h:60: DB::ReadBuffer::next() @ 0x000000000a148c7b 13. /build/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) @ 0x0000000011849fb2 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]>&)>&, 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&) @ 0x0000000011841980 15. /build/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) @ 0x000000001621208e 16. /build/src/Storages/StorageReplicatedMergeTree.cpp:5228: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl[abi:se190107] const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000015f9a5fe 17. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000015ed8bfd 18. /build/src/Storages/StorageReplicatedMergeTree.cpp:2514: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x0000000015ec9aab 19. /build/src/Storages/StorageReplicatedMergeTree.cpp:2349: DB::StorageReplicatedMergeTree::executeLogEntry(DB::ReplicatedMergeTreeLogEntry&) @ 0x0000000015eba91b 20. /build/src/Storages/StorageReplicatedMergeTree.cpp:3876: bool std::__function::__policy_invoker&)>::__call_impl[abi:se190107])::$_1, bool (std::shared_ptr&)>>(std::__function::__policy_storage const*, std::shared_ptr&) @ 0x0000000015f9837e 21. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000165d6fc3 22. /build/src/Storages/StorageReplicatedMergeTree.cpp:3872: DB::StorageReplicatedMergeTree::processQueueEntry(std::shared_ptr) @ 0x0000000015efc18a 23. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001624c1b2 24. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000162f9c70 25. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x00000000162fa55a 26. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc6653 27. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000000fccc4c3 28. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc3d92 29. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fcca080 30. ? @ 0x00007fbc6213eac3 31. ? @ 0x00007fbc621d0850 (version 25.3.6.10636.altinitytest (altinity build)) 2025.07.28 12:00:15.179765 [ 3974 ] {} test_13.rmt2 (7f9b740d-015c-470e-8cc6-8ba33be0dc63): auto DB::StorageReplicatedMergeTree::processQueueEntry(ReplicatedMergeTreeQueue::SelectedEntryPtr)::(anonymous class)::operator()(LogEntryPtr &) const: Code: 86. DB::HTTPException: Received error from remote server http://146b4357c08d:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Ftest%2F01165%2Ftest_13%2Frmt%2Freplicas%2F1&part=20250728_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.6.10636.altinitytest (altinity build)) '. (RECEIVED_ERROR_FROM_REMOTE_IO_SERVER), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.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 const&, int&&, String const&, unsigned long&&, String const&) @ 0x000000000feda8d9 4. /build/src/IO/HTTPCommon.cpp:104: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x000000000feda6e2 5. /build/src/IO/HTTPCommon.cpp:93: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x000000000feda537 6. /build/src/IO/ReadWriteBufferFromHTTP.cpp:277: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x000000001184a4c4 7. /build/src/IO/ReadWriteBufferFromHTTP.cpp:285: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x000000001184a615 8. /build/src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x000000001184ae59 9. /build/src/IO/ReadWriteBufferFromHTTP.cpp:472: void std::__function::__policy_invoker::__call_impl[abi:se190107]>(std::__function::__policy_storage const*) @ 0x000000001184cedd 10. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001184858b 11. /build/src/IO/ReadWriteBufferFromHTTP.cpp:465: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x000000001184bf0b 12. /build/src/IO/ReadBuffer.h:60: DB::ReadBuffer::next() @ 0x000000000a148c7b 13. /build/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) @ 0x0000000011849fb2 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]>&)>&, 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&) @ 0x0000000011841980 15. /build/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) @ 0x000000001621208e 16. /build/src/Storages/StorageReplicatedMergeTree.cpp:5228: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl[abi:se190107] const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000015f9a5fe 17. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000015ed8bfd 18. /build/src/Storages/StorageReplicatedMergeTree.cpp:2514: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x0000000015ec9aab 19. /build/src/Storages/StorageReplicatedMergeTree.cpp:2349: DB::StorageReplicatedMergeTree::executeLogEntry(DB::ReplicatedMergeTreeLogEntry&) @ 0x0000000015eba91b 20. /build/src/Storages/StorageReplicatedMergeTree.cpp:3876: bool std::__function::__policy_invoker&)>::__call_impl[abi:se190107])::$_1, bool (std::shared_ptr&)>>(std::__function::__policy_storage const*, std::shared_ptr&) @ 0x0000000015f9837e 21. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000165d6fc3 22. /build/src/Storages/StorageReplicatedMergeTree.cpp:3872: DB::StorageReplicatedMergeTree::processQueueEntry(std::shared_ptr) @ 0x0000000015efc18a 23. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001624c1b2 24. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000162f9c70 25. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x00000000162fa55a 26. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc6653 27. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000000fccc4c3 28. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc3d92 29. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fcca080 30. ? @ 0x00007fbc6213eac3 31. ? @ 0x00007fbc621d0850 (version 25.3.6.10636.altinitytest (altinity build)) 2025.07.28 12:00:16.152091 [ 3968 ] {} test_13.rmt2 (7f9b740d-015c-470e-8cc6-8ba33be0dc63): auto DB::StorageReplicatedMergeTree::processQueueEntry(ReplicatedMergeTreeQueue::SelectedEntryPtr)::(anonymous class)::operator()(LogEntryPtr &) const: Code: 86. DB::HTTPException: Received error from remote server http://146b4357c08d:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Ftest%2F01165%2Ftest_13%2Frmt%2Freplicas%2F1&part=20250728_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.6.10636.altinitytest (altinity build)) '. (RECEIVED_ERROR_FROM_REMOTE_IO_SERVER), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.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 const&, int&&, String const&, unsigned long&&, String const&) @ 0x000000000feda8d9 4. /build/src/IO/HTTPCommon.cpp:104: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x000000000feda6e2 5. /build/src/IO/HTTPCommon.cpp:93: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x000000000feda537 6. /build/src/IO/ReadWriteBufferFromHTTP.cpp:277: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x000000001184a4c4 7. /build/src/IO/ReadWriteBufferFromHTTP.cpp:285: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x000000001184a615 8. /build/src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x000000001184ae59 9. /build/src/IO/ReadWriteBufferFromHTTP.cpp:472: void std::__function::__policy_invoker::__call_impl[abi:se190107]>(std::__function::__policy_storage const*) @ 0x000000001184cedd 10. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001184858b 11. /build/src/IO/ReadWriteBufferFromHTTP.cpp:465: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x000000001184bf0b 12. /build/src/IO/ReadBuffer.h:60: DB::ReadBuffer::next() @ 0x000000000a148c7b 13. /build/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) @ 0x0000000011849fb2 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]>&)>&, 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&) @ 0x0000000011841980 15. /build/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) @ 0x000000001621208e 16. /build/src/Storages/StorageReplicatedMergeTree.cpp:5228: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl[abi:se190107] const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000015f9a5fe 17. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000015ed8bfd 18. /build/src/Storages/StorageReplicatedMergeTree.cpp:2514: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x0000000015ec9aab 19. /build/src/Storages/StorageReplicatedMergeTree.cpp:2349: DB::StorageReplicatedMergeTree::executeLogEntry(DB::ReplicatedMergeTreeLogEntry&) @ 0x0000000015eba91b 20. /build/src/Storages/StorageReplicatedMergeTree.cpp:3876: bool std::__function::__policy_invoker&)>::__call_impl[abi:se190107])::$_1, bool (std::shared_ptr&)>>(std::__function::__policy_storage const*, std::shared_ptr&) @ 0x0000000015f9837e 21. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000165d6fc3 22. /build/src/Storages/StorageReplicatedMergeTree.cpp:3872: DB::StorageReplicatedMergeTree::processQueueEntry(std::shared_ptr) @ 0x0000000015efc18a 23. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001624c1b2 24. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000162f9c70 25. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x00000000162fa55a 26. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc6653 27. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000000fccc4c3 28. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc3d92 29. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fcca080 30. ? @ 0x00007fbc6213eac3 31. ? @ 0x00007fbc621d0850 (version 25.3.6.10636.altinitytest (altinity build)) 2025.07.28 12:00:16.860981 [ 17203 ] {b6a108bd-da2f-4c00-a7db-db4079594000} executeQuery: Code: 57. DB::Exception: Table test_5.t_order_by_monotonic already exists. (TABLE_ALREADY_EXISTS) (version 25.3.6.10636.altinitytest (altinity build)) (from 0.0.0.0:0) (comment: 02451_order_by_monotonic.sh) (in query: /* ddl_entry=query-0000000127 */ CREATE TABLE test_5.t_order_by_monotonic UUID '9f401956-8564-4a15-ba66-bb4c9402a561' (`a` Int64, `b` Int64) ENGINE = MergeTree ORDER BY (a, b) SETTINGS index_granularity = 4820, min_bytes_for_wide_part = 1022430231, ratio_of_defaults_for_sparse_serialization = 0.6188065409660339, 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 = 515950531, compact_parts_max_granules_to_buffer = 256, compact_parts_merge_max_bytes_to_prefetch_part = 27907927, merge_max_block_size = 13858, 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 = 7708505633, index_granularity_bytes = 6214084, use_const_adaptive_granularity = false, 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 = true, cache_populated_by_fetch = false, marks_compress_block_size = 36312, primary_key_compress_block_size = 98243, 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. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000a06a8eb 4. /build/src/Interpreters/InterpreterCreateQuery.cpp:1824: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x0000000014901d53 5. /build/src/Interpreters/InterpreterCreateQuery.cpp:1743: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000148f9aa9 6. /build/src/Interpreters/InterpreterCreateQuery.cpp:2352: DB::InterpreterCreateQuery::execute() @ 0x0000000014905a41 7. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88dc9 8. /build/src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x0000000014c8ca7b 9. /build/src/Interpreters/DDLWorker.cpp:510: DB::DDLWorker::tryExecuteQuery(DB::DDLTaskBase&, std::shared_ptr const&, bool) @ 0x00000000144dab9e 10. /build/src/Interpreters/DDLWorker.cpp:675: DB::DDLWorker::processTask(DB::DDLTaskBase&, std::shared_ptr const&, bool) @ 0x00000000144d8ffe 11. /build/src/Databases/DatabaseReplicatedWorker.cpp:372: DB::DatabaseReplicatedDDLWorker::tryEnqueueAndExecuteEntry(DB::DDLLogEntry&, std::shared_ptr, bool) @ 0x0000000013dc29ab 12. /build/src/Databases/DatabaseReplicated.cpp:1139: DB::DatabaseReplicated::tryEnqueueReplicatedDDL(std::shared_ptr const&, std::shared_ptr, DB::QueryFlags) @ 0x0000000013d9f73c 13. /build/src/Interpreters/InterpreterCreateQuery.cpp:1723: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000148f96f8 14. /build/src/Interpreters/InterpreterCreateQuery.cpp:2352: DB::InterpreterCreateQuery::execute() @ 0x0000000014905a41 15. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88dc9 16. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 17. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 18. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 19. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 20. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 21. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 22. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 23. ? @ 0x00007fbc6213eac3 24. ? @ 0x00007fbc621d0850 2025.07.28 12:00:16.940933 [ 17203 ] {b6a108bd-da2f-4c00-a7db-db4079594000} executeQuery: Code: 57. DB::Exception: Table test_5.t_order_by_monotonic already exists. (TABLE_ALREADY_EXISTS) (version 25.3.6.10636.altinitytest (altinity build)) (from [::1]:33320) (comment: 02451_order_by_monotonic.sh) (query 1, line 1) (in query: CREATE TABLE t_order_by_monotonic (`a` Int64, `b` Int64) ENGINE = MergeTree ORDER BY (a, b) SETTINGS index_granularity = 4820, min_bytes_for_wide_part = 1022430231, ratio_of_defaults_for_sparse_serialization = 0.6188065409660339, 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 = 515950531, compact_parts_max_granules_to_buffer = 256, compact_parts_merge_max_bytes_to_prefetch_part = 27907927, merge_max_block_size = 13858, 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 = 7708505633, index_granularity_bytes = 6214084, use_const_adaptive_granularity = false, 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 = true, cache_populated_by_fetch = false, marks_compress_block_size = 36312, primary_key_compress_block_size = 98243, 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. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000a06a8eb 4. /build/src/Interpreters/InterpreterCreateQuery.cpp:1824: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x0000000014901d53 5. /build/src/Interpreters/InterpreterCreateQuery.cpp:1743: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000148f9aa9 6. /build/src/Interpreters/InterpreterCreateQuery.cpp:2352: DB::InterpreterCreateQuery::execute() @ 0x0000000014905a41 7. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88dc9 8. /build/src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x0000000014c8ca7b 9. /build/src/Interpreters/DDLWorker.cpp:510: DB::DDLWorker::tryExecuteQuery(DB::DDLTaskBase&, std::shared_ptr const&, bool) @ 0x00000000144dab9e 10. /build/src/Interpreters/DDLWorker.cpp:675: DB::DDLWorker::processTask(DB::DDLTaskBase&, std::shared_ptr const&, bool) @ 0x00000000144d8ffe 11. /build/src/Databases/DatabaseReplicatedWorker.cpp:372: DB::DatabaseReplicatedDDLWorker::tryEnqueueAndExecuteEntry(DB::DDLLogEntry&, std::shared_ptr, bool) @ 0x0000000013dc29ab 12. /build/src/Databases/DatabaseReplicated.cpp:1139: DB::DatabaseReplicated::tryEnqueueReplicatedDDL(std::shared_ptr const&, std::shared_ptr, DB::QueryFlags) @ 0x0000000013d9f73c 13. /build/src/Interpreters/InterpreterCreateQuery.cpp:1723: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000148f96f8 14. /build/src/Interpreters/InterpreterCreateQuery.cpp:2352: DB::InterpreterCreateQuery::execute() @ 0x0000000014905a41 15. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88dc9 16. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 17. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 18. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 19. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 20. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 21. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 22. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 23. ? @ 0x00007fbc6213eac3 24. ? @ 0x00007fbc621d0850 2025.07.28 12:00:16.970089 [ 17203 ] {} TCPHandler: Code: 57. DB::Exception: Table test_5.t_order_by_monotonic already exists. (TABLE_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000a06a8eb 4. /build/src/Interpreters/InterpreterCreateQuery.cpp:1824: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x0000000014901d53 5. /build/src/Interpreters/InterpreterCreateQuery.cpp:1743: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000148f9aa9 6. /build/src/Interpreters/InterpreterCreateQuery.cpp:2352: DB::InterpreterCreateQuery::execute() @ 0x0000000014905a41 7. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88dc9 8. /build/src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x0000000014c8ca7b 9. /build/src/Interpreters/DDLWorker.cpp:510: DB::DDLWorker::tryExecuteQuery(DB::DDLTaskBase&, std::shared_ptr const&, bool) @ 0x00000000144dab9e 10. /build/src/Interpreters/DDLWorker.cpp:675: DB::DDLWorker::processTask(DB::DDLTaskBase&, std::shared_ptr const&, bool) @ 0x00000000144d8ffe 11. /build/src/Databases/DatabaseReplicatedWorker.cpp:372: DB::DatabaseReplicatedDDLWorker::tryEnqueueAndExecuteEntry(DB::DDLLogEntry&, std::shared_ptr, bool) @ 0x0000000013dc29ab 12. /build/src/Databases/DatabaseReplicated.cpp:1139: DB::DatabaseReplicated::tryEnqueueReplicatedDDL(std::shared_ptr const&, std::shared_ptr, DB::QueryFlags) @ 0x0000000013d9f73c 13. /build/src/Interpreters/InterpreterCreateQuery.cpp:1723: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000148f96f8 14. /build/src/Interpreters/InterpreterCreateQuery.cpp:2352: DB::InterpreterCreateQuery::execute() @ 0x0000000014905a41 15. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88dc9 16. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 17. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 18. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 19. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 20. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 21. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 22. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 23. ? @ 0x00007fbc6213eac3 24. ? @ 0x00007fbc621d0850 2025.07.28 12:00:17.100777 [ 3961 ] {} test_13.rmt2 (7f9b740d-015c-470e-8cc6-8ba33be0dc63): auto DB::StorageReplicatedMergeTree::processQueueEntry(ReplicatedMergeTreeQueue::SelectedEntryPtr)::(anonymous class)::operator()(LogEntryPtr &) const: Code: 86. DB::HTTPException: Received error from remote server http://146b4357c08d:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Ftest%2F01165%2Ftest_13%2Frmt%2Freplicas%2F1&part=20250728_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.6.10636.altinitytest (altinity build)) '. (RECEIVED_ERROR_FROM_REMOTE_IO_SERVER), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.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 const&, int&&, String const&, unsigned long&&, String const&) @ 0x000000000feda8d9 4. /build/src/IO/HTTPCommon.cpp:104: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x000000000feda6e2 5. /build/src/IO/HTTPCommon.cpp:93: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x000000000feda537 6. /build/src/IO/ReadWriteBufferFromHTTP.cpp:277: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x000000001184a4c4 7. /build/src/IO/ReadWriteBufferFromHTTP.cpp:285: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x000000001184a615 8. /build/src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x000000001184ae59 9. /build/src/IO/ReadWriteBufferFromHTTP.cpp:472: void std::__function::__policy_invoker::__call_impl[abi:se190107]>(std::__function::__policy_storage const*) @ 0x000000001184cedd 10. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001184858b 11. /build/src/IO/ReadWriteBufferFromHTTP.cpp:465: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x000000001184bf0b 12. /build/src/IO/ReadBuffer.h:60: DB::ReadBuffer::next() @ 0x000000000a148c7b 13. /build/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) @ 0x0000000011849fb2 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]>&)>&, 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&) @ 0x0000000011841980 15. /build/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) @ 0x000000001621208e 16. /build/src/Storages/StorageReplicatedMergeTree.cpp:5228: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl[abi:se190107] const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000015f9a5fe 17. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000015ed8bfd 18. /build/src/Storages/StorageReplicatedMergeTree.cpp:2514: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x0000000015ec9aab 19. /build/src/Storages/StorageReplicatedMergeTree.cpp:2349: DB::StorageReplicatedMergeTree::executeLogEntry(DB::ReplicatedMergeTreeLogEntry&) @ 0x0000000015eba91b 20. /build/src/Storages/StorageReplicatedMergeTree.cpp:3876: bool std::__function::__policy_invoker&)>::__call_impl[abi:se190107])::$_1, bool (std::shared_ptr&)>>(std::__function::__policy_storage const*, std::shared_ptr&) @ 0x0000000015f9837e 21. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000165d6fc3 22. /build/src/Storages/StorageReplicatedMergeTree.cpp:3872: DB::StorageReplicatedMergeTree::processQueueEntry(std::shared_ptr) @ 0x0000000015efc18a 23. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001624c1b2 24. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000162f9c70 25. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x00000000162fa55a 26. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc6653 27. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000000fccc4c3 28. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc3d92 29. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fcca080 30. ? @ 0x00007fbc6213eac3 31. ? @ 0x00007fbc621d0850 (version 25.3.6.10636.altinitytest (altinity build)) 2025.07.28 12:00:17.546283 [ 3970 ] {} test_13.rmt2 (7f9b740d-015c-470e-8cc6-8ba33be0dc63): auto DB::StorageReplicatedMergeTree::processQueueEntry(ReplicatedMergeTreeQueue::SelectedEntryPtr)::(anonymous class)::operator()(LogEntryPtr &) const: Code: 86. DB::HTTPException: Received error from remote server http://146b4357c08d:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Ftest%2F01165%2Ftest_13%2Frmt%2Freplicas%2F1&part=20250728_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.6.10636.altinitytest (altinity build)) '. (RECEIVED_ERROR_FROM_REMOTE_IO_SERVER), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.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 const&, int&&, String const&, unsigned long&&, String const&) @ 0x000000000feda8d9 4. /build/src/IO/HTTPCommon.cpp:104: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x000000000feda6e2 5. /build/src/IO/HTTPCommon.cpp:93: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x000000000feda537 6. /build/src/IO/ReadWriteBufferFromHTTP.cpp:277: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x000000001184a4c4 7. /build/src/IO/ReadWriteBufferFromHTTP.cpp:285: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x000000001184a615 8. /build/src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x000000001184ae59 9. /build/src/IO/ReadWriteBufferFromHTTP.cpp:472: void std::__function::__policy_invoker::__call_impl[abi:se190107]>(std::__function::__policy_storage const*) @ 0x000000001184cedd 10. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001184858b 11. /build/src/IO/ReadWriteBufferFromHTTP.cpp:465: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x000000001184bf0b 12. /build/src/IO/ReadBuffer.h:60: DB::ReadBuffer::next() @ 0x000000000a148c7b 13. /build/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) @ 0x0000000011849fb2 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]>&)>&, 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&) @ 0x0000000011841980 15. /build/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) @ 0x000000001621208e 16. /build/src/Storages/StorageReplicatedMergeTree.cpp:5228: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl[abi:se190107] const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000015f9a5fe 17. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000015ed8bfd 18. /build/src/Storages/StorageReplicatedMergeTree.cpp:2514: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x0000000015ec9aab 19. /build/src/Storages/StorageReplicatedMergeTree.cpp:2349: DB::StorageReplicatedMergeTree::executeLogEntry(DB::ReplicatedMergeTreeLogEntry&) @ 0x0000000015eba91b 20. /build/src/Storages/StorageReplicatedMergeTree.cpp:3876: bool std::__function::__policy_invoker&)>::__call_impl[abi:se190107])::$_1, bool (std::shared_ptr&)>>(std::__function::__policy_storage const*, std::shared_ptr&) @ 0x0000000015f9837e 21. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000165d6fc3 22. /build/src/Storages/StorageReplicatedMergeTree.cpp:3872: DB::StorageReplicatedMergeTree::processQueueEntry(std::shared_ptr) @ 0x0000000015efc18a 23. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001624c1b2 24. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000162f9c70 25. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x00000000162fa55a 26. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc6653 27. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000000fccc4c3 28. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc3d92 29. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fcca080 30. ? @ 0x00007fbc6213eac3 31. ? @ 0x00007fbc621d0850 (version 25.3.6.10636.altinitytest (altinity build)) 2025.07.28 12:00:17.686575 [ 3964 ] {} test_13.rmt2 (7f9b740d-015c-470e-8cc6-8ba33be0dc63): auto DB::StorageReplicatedMergeTree::processQueueEntry(ReplicatedMergeTreeQueue::SelectedEntryPtr)::(anonymous class)::operator()(LogEntryPtr &) const: Code: 86. DB::HTTPException: Received error from remote server http://146b4357c08d:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Ftest%2F01165%2Ftest_13%2Frmt%2Freplicas%2F1&part=20250728_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.6.10636.altinitytest (altinity build)) '. (RECEIVED_ERROR_FROM_REMOTE_IO_SERVER), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.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 const&, int&&, String const&, unsigned long&&, String const&) @ 0x000000000feda8d9 4. /build/src/IO/HTTPCommon.cpp:104: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x000000000feda6e2 5. /build/src/IO/HTTPCommon.cpp:93: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x000000000feda537 6. /build/src/IO/ReadWriteBufferFromHTTP.cpp:277: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x000000001184a4c4 7. /build/src/IO/ReadWriteBufferFromHTTP.cpp:285: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x000000001184a615 8. /build/src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x000000001184ae59 9. /build/src/IO/ReadWriteBufferFromHTTP.cpp:472: void std::__function::__policy_invoker::__call_impl[abi:se190107]>(std::__function::__policy_storage const*) @ 0x000000001184cedd 10. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001184858b 11. /build/src/IO/ReadWriteBufferFromHTTP.cpp:465: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x000000001184bf0b 12. /build/src/IO/ReadBuffer.h:60: DB::ReadBuffer::next() @ 0x000000000a148c7b 13. /build/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) @ 0x0000000011849fb2 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]>&)>&, 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&) @ 0x0000000011841980 15. /build/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) @ 0x000000001621208e 16. /build/src/Storages/StorageReplicatedMergeTree.cpp:5228: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl[abi:se190107] const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000015f9a5fe 17. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000015ed8bfd 18. /build/src/Storages/StorageReplicatedMergeTree.cpp:2514: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x0000000015ec9aab 19. /build/src/Storages/StorageReplicatedMergeTree.cpp:2349: DB::StorageReplicatedMergeTree::executeLogEntry(DB::ReplicatedMergeTreeLogEntry&) @ 0x0000000015eba91b 20. /build/src/Storages/StorageReplicatedMergeTree.cpp:3876: bool std::__function::__policy_invoker&)>::__call_impl[abi:se190107])::$_1, bool (std::shared_ptr&)>>(std::__function::__policy_storage const*, std::shared_ptr&) @ 0x0000000015f9837e 21. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000165d6fc3 22. /build/src/Storages/StorageReplicatedMergeTree.cpp:3872: DB::StorageReplicatedMergeTree::processQueueEntry(std::shared_ptr) @ 0x0000000015efc18a 23. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001624c1b2 24. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000162f9c70 25. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x00000000162fa55a 26. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc6653 27. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000000fccc4c3 28. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc3d92 29. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fcca080 30. ? @ 0x00007fbc6213eac3 31. ? @ 0x00007fbc621d0850 (version 25.3.6.10636.altinitytest (altinity build)) 2025.07.28 12:00:17.718276 [ 17371 ] {0c87b0d6-11db-4ca0-954d-86e0a3539a54} executeQuery: Code: 47. DB::Exception: Unknown expression or function identifier `a` in scope SELECT * FROM t_order_by_monotonic AS test ORDER BY -a ASC. Maybe you meant: ['t']. (UNKNOWN_IDENTIFIER) (version 25.3.6.10636.altinitytest (altinity build)) (from [::1]:33358) (comment: 02451_order_by_monotonic.sh) (query 1, line 1) (in query: EXPLAIN PLAN actions = 1 SELECT * FROM t_order_by_monotonic AS test ORDER BY -a), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.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&&) @ 0x000000001404b3b9 4. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3771: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000001401b849 5. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3980: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000014018e31 6. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:2925: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000001402fcbd 7. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3838: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000014019a9e 8. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:4023: DB::QueryAnalyzer::resolveSortNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000001403fb99 9. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5656: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000014013cc8 10. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000140127f9 11. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000014011fce 12. /build/src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000001406ce8a 13. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000014973b42 14. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000001497268d 15. /build/src/Interpreters/InterpreterExplainQuery.cpp:507: DB::InterpreterExplainQuery::executeImpl() @ 0x000000001491a4eb 16. /build/src/Interpreters/InterpreterExplainQuery.cpp:130: DB::InterpreterExplainQuery::execute() @ 0x0000000014919fc7 17. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88dc9 18. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 19. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 20. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 21. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 22. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 23. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 24. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 25. ? @ 0x00007fbc6213eac3 26. ? @ 0x00007fbc621d0850 2025.07.28 12:00:17.738133 [ 17371 ] {} TCPHandler: Code: 47. DB::Exception: Unknown expression or function identifier `a` in scope SELECT * FROM t_order_by_monotonic AS test ORDER BY -a ASC. Maybe you meant: ['t']. (UNKNOWN_IDENTIFIER), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.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&&) @ 0x000000001404b3b9 4. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3771: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000001401b849 5. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3980: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000014018e31 6. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:2925: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000001402fcbd 7. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3838: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000014019a9e 8. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:4023: DB::QueryAnalyzer::resolveSortNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000001403fb99 9. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5656: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000014013cc8 10. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000140127f9 11. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000014011fce 12. /build/src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000001406ce8a 13. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000014973b42 14. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000001497268d 15. /build/src/Interpreters/InterpreterExplainQuery.cpp:507: DB::InterpreterExplainQuery::executeImpl() @ 0x000000001491a4eb 16. /build/src/Interpreters/InterpreterExplainQuery.cpp:130: DB::InterpreterExplainQuery::execute() @ 0x0000000014919fc7 17. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88dc9 18. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 19. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 20. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 21. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 22. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 23. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 24. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 25. ? @ 0x00007fbc6213eac3 26. ? @ 0x00007fbc621d0850 2025.07.28 12:00:18.018924 [ 17371 ] {ea06d2d1-f4c6-40f8-b4bf-a051d13fc6d0} executeQuery: Code: 47. DB::Exception: Unknown expression or function identifier `a` in scope SELECT * FROM t_order_by_monotonic AS test ORDER BY -a ASC, -b ASC. Maybe you meant: ['t']. (UNKNOWN_IDENTIFIER) (version 25.3.6.10636.altinitytest (altinity build)) (from [::1]:33374) (comment: 02451_order_by_monotonic.sh) (query 1, line 1) (in query: EXPLAIN PLAN actions = 1 SELECT * FROM t_order_by_monotonic AS test ORDER BY -a, -b), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.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&&) @ 0x000000001404b3b9 4. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3771: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000001401b849 5. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3980: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000014018e31 6. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:2925: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000001402fcbd 7. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3838: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000014019a9e 8. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:4023: DB::QueryAnalyzer::resolveSortNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000001403fb99 9. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5656: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000014013cc8 10. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000140127f9 11. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000014011fce 12. /build/src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000001406ce8a 13. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000014973b42 14. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000001497268d 15. /build/src/Interpreters/InterpreterExplainQuery.cpp:507: DB::InterpreterExplainQuery::executeImpl() @ 0x000000001491a4eb 16. /build/src/Interpreters/InterpreterExplainQuery.cpp:130: DB::InterpreterExplainQuery::execute() @ 0x0000000014919fc7 17. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88dc9 18. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 19. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 20. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 21. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 22. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 23. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 24. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 25. ? @ 0x00007fbc6213eac3 26. ? @ 0x00007fbc621d0850 2025.07.28 12:00:18.068617 [ 17371 ] {} TCPHandler: Code: 47. DB::Exception: Unknown expression or function identifier `a` in scope SELECT * FROM t_order_by_monotonic AS test ORDER BY -a ASC, -b ASC. Maybe you meant: ['t']. (UNKNOWN_IDENTIFIER), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.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&&) @ 0x000000001404b3b9 4. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3771: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000001401b849 5. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3980: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000014018e31 6. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:2925: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000001402fcbd 7. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3838: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000014019a9e 8. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:4023: DB::QueryAnalyzer::resolveSortNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000001403fb99 9. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5656: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000014013cc8 10. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000140127f9 11. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000014011fce 12. /build/src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000001406ce8a 13. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000014973b42 14. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000001497268d 15. /build/src/Interpreters/InterpreterExplainQuery.cpp:507: DB::InterpreterExplainQuery::executeImpl() @ 0x000000001491a4eb 16. /build/src/Interpreters/InterpreterExplainQuery.cpp:130: DB::InterpreterExplainQuery::execute() @ 0x0000000014919fc7 17. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88dc9 18. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 19. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 20. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 21. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 22. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 23. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 24. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 25. ? @ 0x00007fbc6213eac3 26. ? @ 0x00007fbc621d0850 2025.07.28 12:00:18.402860 [ 17371 ] {18b340f4-780b-44ab-a57b-f2bb06265110} executeQuery: Code: 47. DB::Exception: Unknown expression identifier `a` in scope SELECT * FROM t_order_by_monotonic AS test ORDER BY a DESC, -b ASC. Maybe you meant: ['t']. (UNKNOWN_IDENTIFIER) (version 25.3.6.10636.altinitytest (altinity build)) (from [::1]:33382) (comment: 02451_order_by_monotonic.sh) (query 1, line 1) (in query: EXPLAIN PLAN actions = 1 SELECT * FROM t_order_by_monotonic AS test ORDER BY a DESC, -b), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.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&&) @ 0x000000001404b3b9 4. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3771: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000001401b849 5. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:4023: DB::QueryAnalyzer::resolveSortNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000001403fb99 6. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5656: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000014013cc8 7. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000140127f9 8. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000014011fce 9. /build/src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000001406ce8a 10. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000014973b42 11. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000001497268d 12. /build/src/Interpreters/InterpreterExplainQuery.cpp:507: DB::InterpreterExplainQuery::executeImpl() @ 0x000000001491a4eb 13. /build/src/Interpreters/InterpreterExplainQuery.cpp:130: DB::InterpreterExplainQuery::execute() @ 0x0000000014919fc7 14. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88dc9 15. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 16. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 17. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 18. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 19. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 20. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 21. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 22. ? @ 0x00007fbc6213eac3 23. ? @ 0x00007fbc621d0850 2025.07.28 12:00:18.463151 [ 17371 ] {} TCPHandler: Code: 47. DB::Exception: Unknown expression identifier `a` in scope SELECT * FROM t_order_by_monotonic AS test ORDER BY a DESC, -b ASC. Maybe you meant: ['t']. (UNKNOWN_IDENTIFIER), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.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&&) @ 0x000000001404b3b9 4. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3771: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000001401b849 5. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:4023: DB::QueryAnalyzer::resolveSortNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000001403fb99 6. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5656: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000014013cc8 7. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000140127f9 8. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000014011fce 9. /build/src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000001406ce8a 10. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000014973b42 11. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000001497268d 12. /build/src/Interpreters/InterpreterExplainQuery.cpp:507: DB::InterpreterExplainQuery::executeImpl() @ 0x000000001491a4eb 13. /build/src/Interpreters/InterpreterExplainQuery.cpp:130: DB::InterpreterExplainQuery::execute() @ 0x0000000014919fc7 14. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88dc9 15. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 16. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 17. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 18. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 19. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 20. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 21. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 22. ? @ 0x00007fbc6213eac3 23. ? @ 0x00007fbc621d0850 2025.07.28 12:00:18.488834 [ 3976 ] {} test_13.rmt2 (7f9b740d-015c-470e-8cc6-8ba33be0dc63): auto DB::StorageReplicatedMergeTree::processQueueEntry(ReplicatedMergeTreeQueue::SelectedEntryPtr)::(anonymous class)::operator()(LogEntryPtr &) const: Code: 86. DB::HTTPException: Received error from remote server http://146b4357c08d:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Ftest%2F01165%2Ftest_13%2Frmt%2Freplicas%2F1&part=20250728_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.6.10636.altinitytest (altinity build)) '. (RECEIVED_ERROR_FROM_REMOTE_IO_SERVER), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.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 const&, int&&, String const&, unsigned long&&, String const&) @ 0x000000000feda8d9 4. /build/src/IO/HTTPCommon.cpp:104: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x000000000feda6e2 5. /build/src/IO/HTTPCommon.cpp:93: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x000000000feda537 6. /build/src/IO/ReadWriteBufferFromHTTP.cpp:277: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x000000001184a4c4 7. /build/src/IO/ReadWriteBufferFromHTTP.cpp:285: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x000000001184a615 8. /build/src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x000000001184ae59 9. /build/src/IO/ReadWriteBufferFromHTTP.cpp:472: void std::__function::__policy_invoker::__call_impl[abi:se190107]>(std::__function::__policy_storage const*) @ 0x000000001184cedd 10. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001184858b 11. /build/src/IO/ReadWriteBufferFromHTTP.cpp:465: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x000000001184bf0b 12. /build/src/IO/ReadBuffer.h:60: DB::ReadBuffer::next() @ 0x000000000a148c7b 13. /build/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) @ 0x0000000011849fb2 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]>&)>&, 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&) @ 0x0000000011841980 15. /build/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) @ 0x000000001621208e 16. /build/src/Storages/StorageReplicatedMergeTree.cpp:5228: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl[abi:se190107] const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000015f9a5fe 17. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000015ed8bfd 18. /build/src/Storages/StorageReplicatedMergeTree.cpp:2514: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x0000000015ec9aab 19. /build/src/Storages/StorageReplicatedMergeTree.cpp:2349: DB::StorageReplicatedMergeTree::executeLogEntry(DB::ReplicatedMergeTreeLogEntry&) @ 0x0000000015eba91b 20. /build/src/Storages/StorageReplicatedMergeTree.cpp:3876: bool std::__function::__policy_invoker&)>::__call_impl[abi:se190107])::$_1, bool (std::shared_ptr&)>>(std::__function::__policy_storage const*, std::shared_ptr&) @ 0x0000000015f9837e 21. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000165d6fc3 22. /build/src/Storages/StorageReplicatedMergeTree.cpp:3872: DB::StorageReplicatedMergeTree::processQueueEntry(std::shared_ptr) @ 0x0000000015efc18a 23. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001624c1b2 24. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000162f9c70 25. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x00000000162fa55a 26. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc6653 27. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000000fccc4c3 28. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc3d92 29. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fcca080 30. ? @ 0x00007fbc6213eac3 31. ? @ 0x00007fbc621d0850 (version 25.3.6.10636.altinitytest (altinity build)) 2025.07.28 12:00:18.724236 [ 3966 ] {} test_13.rmt2 (7f9b740d-015c-470e-8cc6-8ba33be0dc63): auto DB::StorageReplicatedMergeTree::processQueueEntry(ReplicatedMergeTreeQueue::SelectedEntryPtr)::(anonymous class)::operator()(LogEntryPtr &) const: Code: 86. DB::HTTPException: Received error from remote server http://146b4357c08d:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Ftest%2F01165%2Ftest_13%2Frmt%2Freplicas%2F1&part=20250728_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.6.10636.altinitytest (altinity build)) '. (RECEIVED_ERROR_FROM_REMOTE_IO_SERVER), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.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 const&, int&&, String const&, unsigned long&&, String const&) @ 0x000000000feda8d9 4. /build/src/IO/HTTPCommon.cpp:104: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x000000000feda6e2 5. /build/src/IO/HTTPCommon.cpp:93: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x000000000feda537 6. /build/src/IO/ReadWriteBufferFromHTTP.cpp:277: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x000000001184a4c4 7. /build/src/IO/ReadWriteBufferFromHTTP.cpp:285: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x000000001184a615 8. /build/src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x000000001184ae59 9. /build/src/IO/ReadWriteBufferFromHTTP.cpp:472: void std::__function::__policy_invoker::__call_impl[abi:se190107]>(std::__function::__policy_storage const*) @ 0x000000001184cedd 10. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001184858b 11. /build/src/IO/ReadWriteBufferFromHTTP.cpp:465: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x000000001184bf0b 12. /build/src/IO/ReadBuffer.h:60: DB::ReadBuffer::next() @ 0x000000000a148c7b 13. /build/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) @ 0x0000000011849fb2 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]>&)>&, 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&) @ 0x0000000011841980 15. /build/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) @ 0x000000001621208e 16. /build/src/Storages/StorageReplicatedMergeTree.cpp:5228: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl[abi:se190107] const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000015f9a5fe 17. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000015ed8bfd 18. /build/src/Storages/StorageReplicatedMergeTree.cpp:2514: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x0000000015ec9aab 19. /build/src/Storages/StorageReplicatedMergeTree.cpp:2349: DB::StorageReplicatedMergeTree::executeLogEntry(DB::ReplicatedMergeTreeLogEntry&) @ 0x0000000015eba91b 20. /build/src/Storages/StorageReplicatedMergeTree.cpp:3876: bool std::__function::__policy_invoker&)>::__call_impl[abi:se190107])::$_1, bool (std::shared_ptr&)>>(std::__function::__policy_storage const*, std::shared_ptr&) @ 0x0000000015f9837e 21. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000165d6fc3 22. /build/src/Storages/StorageReplicatedMergeTree.cpp:3872: DB::StorageReplicatedMergeTree::processQueueEntry(std::shared_ptr) @ 0x0000000015efc18a 23. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001624c1b2 24. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000162f9c70 25. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x00000000162fa55a 26. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc6653 27. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000000fccc4c3 28. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc3d92 29. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fcca080 30. ? @ 0x00007fbc6213eac3 31. ? @ 0x00007fbc621d0850 (version 25.3.6.10636.altinitytest (altinity build)) 2025.07.28 12:00:18.776832 [ 17371 ] {17786c2c-4231-4d94-b37f-ebc25e44e8ac} executeQuery: Code: 47. DB::Exception: Unknown expression or function identifier `a` in scope SELECT * FROM t_order_by_monotonic AS test ORDER BY -a ASC, b DESC. Maybe you meant: ['t']. (UNKNOWN_IDENTIFIER) (version 25.3.6.10636.altinitytest (altinity build)) (from [::1]:33398) (comment: 02451_order_by_monotonic.sh) (query 1, line 1) (in query: EXPLAIN PLAN actions = 1 SELECT * FROM t_order_by_monotonic AS test ORDER BY -a, b DESC), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.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&&) @ 0x000000001404b3b9 4. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3771: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000001401b849 5. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3980: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000014018e31 6. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:2925: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000001402fcbd 7. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3838: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000014019a9e 8. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:4023: DB::QueryAnalyzer::resolveSortNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000001403fb99 9. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5656: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000014013cc8 10. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000140127f9 11. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000014011fce 12. /build/src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000001406ce8a 13. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000014973b42 14. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000001497268d 15. /build/src/Interpreters/InterpreterExplainQuery.cpp:507: DB::InterpreterExplainQuery::executeImpl() @ 0x000000001491a4eb 16. /build/src/Interpreters/InterpreterExplainQuery.cpp:130: DB::InterpreterExplainQuery::execute() @ 0x0000000014919fc7 17. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88dc9 18. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 19. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 20. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 21. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 22. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 23. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 24. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 25. ? @ 0x00007fbc6213eac3 26. ? @ 0x00007fbc621d0850 2025.07.28 12:00:18.805353 [ 17371 ] {} TCPHandler: Code: 47. DB::Exception: Unknown expression or function identifier `a` in scope SELECT * FROM t_order_by_monotonic AS test ORDER BY -a ASC, b DESC. Maybe you meant: ['t']. (UNKNOWN_IDENTIFIER), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.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&&) @ 0x000000001404b3b9 4. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3771: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000001401b849 5. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3980: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000014018e31 6. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:2925: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000001402fcbd 7. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3838: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000014019a9e 8. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:4023: DB::QueryAnalyzer::resolveSortNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000001403fb99 9. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5656: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000014013cc8 10. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000140127f9 11. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000014011fce 12. /build/src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000001406ce8a 13. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000014973b42 14. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000001497268d 15. /build/src/Interpreters/InterpreterExplainQuery.cpp:507: DB::InterpreterExplainQuery::executeImpl() @ 0x000000001491a4eb 16. /build/src/Interpreters/InterpreterExplainQuery.cpp:130: DB::InterpreterExplainQuery::execute() @ 0x0000000014919fc7 17. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88dc9 18. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 19. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 20. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 21. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 22. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 23. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 24. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 25. ? @ 0x00007fbc6213eac3 26. ? @ 0x00007fbc621d0850 2025.07.28 12:00:18.958774 [ 17371 ] {555fda80-dc49-4ba1-a884-59e3aa94eef2} executeQuery: Code: 47. DB::Exception: Unknown expression or function identifier `a` in scope SELECT * FROM t_order_by_monotonic AS test ORDER BY -a ASC, b ASC. Maybe you meant: ['t']. (UNKNOWN_IDENTIFIER) (version 25.3.6.10636.altinitytest (altinity build)) (from [::1]:33406) (comment: 02451_order_by_monotonic.sh) (query 1, line 1) (in query: EXPLAIN PLAN actions = 1 SELECT * FROM t_order_by_monotonic AS test ORDER BY -a, b), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.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&&) @ 0x000000001404b3b9 4. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3771: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000001401b849 5. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3980: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000014018e31 6. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:2925: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000001402fcbd 7. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3838: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000014019a9e 8. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:4023: DB::QueryAnalyzer::resolveSortNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000001403fb99 9. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5656: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000014013cc8 10. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000140127f9 11. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000014011fce 12. /build/src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000001406ce8a 13. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000014973b42 14. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000001497268d 15. /build/src/Interpreters/InterpreterExplainQuery.cpp:507: DB::InterpreterExplainQuery::executeImpl() @ 0x000000001491a4eb 16. /build/src/Interpreters/InterpreterExplainQuery.cpp:130: DB::InterpreterExplainQuery::execute() @ 0x0000000014919fc7 17. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88dc9 18. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 19. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 20. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 21. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 22. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 23. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 24. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 25. ? @ 0x00007fbc6213eac3 26. ? @ 0x00007fbc621d0850 2025.07.28 12:00:18.980248 [ 17371 ] {} TCPHandler: Code: 47. DB::Exception: Unknown expression or function identifier `a` in scope SELECT * FROM t_order_by_monotonic AS test ORDER BY -a ASC, b ASC. Maybe you meant: ['t']. (UNKNOWN_IDENTIFIER), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.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&&) @ 0x000000001404b3b9 4. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3771: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000001401b849 5. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3980: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000014018e31 6. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:2925: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000001402fcbd 7. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3838: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000014019a9e 8. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:4023: DB::QueryAnalyzer::resolveSortNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000001403fb99 9. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5656: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000014013cc8 10. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000140127f9 11. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000014011fce 12. /build/src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000001406ce8a 13. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000014973b42 14. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000001497268d 15. /build/src/Interpreters/InterpreterExplainQuery.cpp:507: DB::InterpreterExplainQuery::executeImpl() @ 0x000000001491a4eb 16. /build/src/Interpreters/InterpreterExplainQuery.cpp:130: DB::InterpreterExplainQuery::execute() @ 0x0000000014919fc7 17. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88dc9 18. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 19. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 20. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 21. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 22. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 23. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 24. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 25. ? @ 0x00007fbc6213eac3 26. ? @ 0x00007fbc621d0850 2025.07.28 12:00:19.203685 [ 17371 ] {fb85fa5f-ca0e-44e3-979e-dc6fe4e4d653} executeQuery: Code: 47. DB::Exception: Unknown expression identifier `a` in scope SELECT * FROM t_order_by_monotonic AS test ORDER BY a ASC, -b ASC. Maybe you meant: ['t']. (UNKNOWN_IDENTIFIER) (version 25.3.6.10636.altinitytest (altinity build)) (from [::1]:33418) (comment: 02451_order_by_monotonic.sh) (query 1, line 1) (in query: EXPLAIN PLAN actions = 1 SELECT * FROM t_order_by_monotonic AS test ORDER BY a, -b), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.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&&) @ 0x000000001404b3b9 4. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3771: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000001401b849 5. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:4023: DB::QueryAnalyzer::resolveSortNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000001403fb99 6. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5656: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000014013cc8 7. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000140127f9 8. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000014011fce 9. /build/src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000001406ce8a 10. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000014973b42 11. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000001497268d 12. /build/src/Interpreters/InterpreterExplainQuery.cpp:507: DB::InterpreterExplainQuery::executeImpl() @ 0x000000001491a4eb 13. /build/src/Interpreters/InterpreterExplainQuery.cpp:130: DB::InterpreterExplainQuery::execute() @ 0x0000000014919fc7 14. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88dc9 15. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 16. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 17. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 18. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 19. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 20. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 21. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 22. ? @ 0x00007fbc6213eac3 23. ? @ 0x00007fbc621d0850 2025.07.28 12:00:19.229753 [ 17371 ] {} TCPHandler: Code: 47. DB::Exception: Unknown expression identifier `a` in scope SELECT * FROM t_order_by_monotonic AS test ORDER BY a ASC, -b ASC. Maybe you meant: ['t']. (UNKNOWN_IDENTIFIER), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.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&&) @ 0x000000001404b3b9 4. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3771: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000001401b849 5. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:4023: DB::QueryAnalyzer::resolveSortNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000001403fb99 6. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5656: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000014013cc8 7. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000140127f9 8. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000014011fce 9. /build/src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000001406ce8a 10. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000014973b42 11. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000001497268d 12. /build/src/Interpreters/InterpreterExplainQuery.cpp:507: DB::InterpreterExplainQuery::executeImpl() @ 0x000000001491a4eb 13. /build/src/Interpreters/InterpreterExplainQuery.cpp:130: DB::InterpreterExplainQuery::execute() @ 0x0000000014919fc7 14. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88dc9 15. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 16. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 17. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 18. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 19. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 20. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 21. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 22. ? @ 0x00007fbc6213eac3 23. ? @ 0x00007fbc621d0850 2025.07.28 12:00:19.324826 [ 3972 ] {} test_13.rmt2 (7f9b740d-015c-470e-8cc6-8ba33be0dc63): auto DB::StorageReplicatedMergeTree::processQueueEntry(ReplicatedMergeTreeQueue::SelectedEntryPtr)::(anonymous class)::operator()(LogEntryPtr &) const: Code: 86. DB::HTTPException: Received error from remote server http://146b4357c08d:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Ftest%2F01165%2Ftest_13%2Frmt%2Freplicas%2F1&part=20250728_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.6.10636.altinitytest (altinity build)) '. (RECEIVED_ERROR_FROM_REMOTE_IO_SERVER), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.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 const&, int&&, String const&, unsigned long&&, String const&) @ 0x000000000feda8d9 4. /build/src/IO/HTTPCommon.cpp:104: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x000000000feda6e2 5. /build/src/IO/HTTPCommon.cpp:93: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x000000000feda537 6. /build/src/IO/ReadWriteBufferFromHTTP.cpp:277: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x000000001184a4c4 7. /build/src/IO/ReadWriteBufferFromHTTP.cpp:285: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x000000001184a615 8. /build/src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x000000001184ae59 9. /build/src/IO/ReadWriteBufferFromHTTP.cpp:472: void std::__function::__policy_invoker::__call_impl[abi:se190107]>(std::__function::__policy_storage const*) @ 0x000000001184cedd 10. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001184858b 11. /build/src/IO/ReadWriteBufferFromHTTP.cpp:465: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x000000001184bf0b 12. /build/src/IO/ReadBuffer.h:60: DB::ReadBuffer::next() @ 0x000000000a148c7b 13. /build/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) @ 0x0000000011849fb2 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]>&)>&, 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&) @ 0x0000000011841980 15. /build/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) @ 0x000000001621208e 16. /build/src/Storages/StorageReplicatedMergeTree.cpp:5228: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl[abi:se190107] const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000015f9a5fe 17. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000015ed8bfd 18. /build/src/Storages/StorageReplicatedMergeTree.cpp:2514: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x0000000015ec9aab 19. /build/src/Storages/StorageReplicatedMergeTree.cpp:2349: DB::StorageReplicatedMergeTree::executeLogEntry(DB::ReplicatedMergeTreeLogEntry&) @ 0x0000000015eba91b 20. /build/src/Storages/StorageReplicatedMergeTree.cpp:3876: bool std::__function::__policy_invoker&)>::__call_impl[abi:se190107])::$_1, bool (std::shared_ptr&)>>(std::__function::__policy_storage const*, std::shared_ptr&) @ 0x0000000015f9837e 21. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000165d6fc3 22. /build/src/Storages/StorageReplicatedMergeTree.cpp:3872: DB::StorageReplicatedMergeTree::processQueueEntry(std::shared_ptr) @ 0x0000000015efc18a 23. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001624c1b2 24. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000162f9c70 25. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x00000000162fa55a 26. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc6653 27. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000000fccc4c3 28. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc3d92 29. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fcca080 30. ? @ 0x00007fbc6213eac3 31. ? @ 0x00007fbc621d0850 (version 25.3.6.10636.altinitytest (altinity build)) 2025.07.28 12:00:19.541922 [ 17306 ] {e55b1b31-bcea-42a7-b843-30d4d07e26b2} executeQuery: Code: 439. DB::Exception: Cannot schedule a task: failed to start the thread (threads=1, jobs=1). (CANNOT_SCHEDULE_TASK) (version 25.3.6.10636.altinitytest (altinity build)) (from [::1]:39414) (comment: 00091_union_race_conditions_2.sh) (query 40, line 40) (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. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000fccaeeb 4. /build/src/Common/ThreadPool.cpp:275: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000fccc813 5. /build/src/Common/ThreadPool.cpp:308: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fcc8286 6. /build/src/Common/ThreadPool.cpp:494: ThreadPoolImpl>::scheduleOrThrowOnError(std::function, Priority) @ 0x000000000fcc7a0e 7. /build/src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::spawnThreadsImpl() @ 0x00000000169b2c0c 8. /build/src/Processors/Executors/PipelineExecutor.cpp:394: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x00000000169b0ba7 9. /build/src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x00000000169b03f4 10. /build/src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:se190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169bfeab 11. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc3d92 12. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fcca080 13. ? @ 0x00007fbc6213eac3 14. ? @ 0x00007fbc621d0850 2025.07.28 12:00:19.568468 [ 17306 ] {} 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. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000fccaeeb 4. /build/src/Common/ThreadPool.cpp:275: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000fccc813 5. /build/src/Common/ThreadPool.cpp:308: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fcc8286 6. /build/src/Common/ThreadPool.cpp:494: ThreadPoolImpl>::scheduleOrThrowOnError(std::function, Priority) @ 0x000000000fcc7a0e 7. /build/src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::spawnThreadsImpl() @ 0x00000000169b2c0c 8. /build/src/Processors/Executors/PipelineExecutor.cpp:394: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x00000000169b0ba7 9. /build/src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x00000000169b03f4 10. /build/src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:se190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169bfeab 11. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc3d92 12. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fcca080 13. ? @ 0x00007fbc6213eac3 14. ? @ 0x00007fbc621d0850 Job's origin stack trace: 0. /build/src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000000fc33b84 1. /build/src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000000fcc2ea7 2. /build/src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fcc535c 3. /build/src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000000fcc584d 4. /build/src/Common/ThreadPool.h:279: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x00000000169bf193 5. /build/src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x00000000169bf518 6. /build/src/Server/TCPHandler.cpp:1237: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x00000000168f1525 7. /build/src/Server/TCPHandler.cpp:678: DB::TCPHandler::runImpl() @ 0x00000000168e68e5 8. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 9. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 10. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 11. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 12. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 13. ? @ 0x00007fbc6213eac3 14. ? @ 0x00007fbc621d0850 2025.07.28 12:00:20.296830 [ 3977 ] {} test_13.rmt2 (7f9b740d-015c-470e-8cc6-8ba33be0dc63): auto DB::StorageReplicatedMergeTree::processQueueEntry(ReplicatedMergeTreeQueue::SelectedEntryPtr)::(anonymous class)::operator()(LogEntryPtr &) const: Code: 86. DB::HTTPException: Received error from remote server http://146b4357c08d:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Ftest%2F01165%2Ftest_13%2Frmt%2Freplicas%2F1&part=20250728_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.6.10636.altinitytest (altinity build)) '. (RECEIVED_ERROR_FROM_REMOTE_IO_SERVER), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.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 const&, int&&, String const&, unsigned long&&, String const&) @ 0x000000000feda8d9 4. /build/src/IO/HTTPCommon.cpp:104: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x000000000feda6e2 5. /build/src/IO/HTTPCommon.cpp:93: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x000000000feda537 6. /build/src/IO/ReadWriteBufferFromHTTP.cpp:277: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x000000001184a4c4 7. /build/src/IO/ReadWriteBufferFromHTTP.cpp:285: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x000000001184a615 8. /build/src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x000000001184ae59 9. /build/src/IO/ReadWriteBufferFromHTTP.cpp:472: void std::__function::__policy_invoker::__call_impl[abi:se190107]>(std::__function::__policy_storage const*) @ 0x000000001184cedd 10. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001184858b 11. /build/src/IO/ReadWriteBufferFromHTTP.cpp:465: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x000000001184bf0b 12. /build/src/IO/ReadBuffer.h:60: DB::ReadBuffer::next() @ 0x000000000a148c7b 13. /build/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) @ 0x0000000011849fb2 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]>&)>&, 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&) @ 0x0000000011841980 15. /build/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) @ 0x000000001621208e 16. /build/src/Storages/StorageReplicatedMergeTree.cpp:5228: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl[abi:se190107] const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000015f9a5fe 17. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000015ed8bfd 18. /build/src/Storages/StorageReplicatedMergeTree.cpp:2514: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x0000000015ec9aab 19. /build/src/Storages/StorageReplicatedMergeTree.cpp:2349: DB::StorageReplicatedMergeTree::executeLogEntry(DB::ReplicatedMergeTreeLogEntry&) @ 0x0000000015eba91b 20. /build/src/Storages/StorageReplicatedMergeTree.cpp:3876: bool std::__function::__policy_invoker&)>::__call_impl[abi:se190107])::$_1, bool (std::shared_ptr&)>>(std::__function::__policy_storage const*, std::shared_ptr&) @ 0x0000000015f9837e 21. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000165d6fc3 22. /build/src/Storages/StorageReplicatedMergeTree.cpp:3872: DB::StorageReplicatedMergeTree::processQueueEntry(std::shared_ptr) @ 0x0000000015efc18a 23. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001624c1b2 24. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000162f9c70 25. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x00000000162fa55a 26. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc6653 27. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000000fccc4c3 28. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc3d92 29. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fcca080 30. ? @ 0x00007fbc6213eac3 31. ? @ 0x00007fbc621d0850 (version 25.3.6.10636.altinitytest (altinity build)) 2025.07.28 12:00:21.063616 [ 3968 ] {} test_13.rmt2 (7f9b740d-015c-470e-8cc6-8ba33be0dc63): auto DB::StorageReplicatedMergeTree::processQueueEntry(ReplicatedMergeTreeQueue::SelectedEntryPtr)::(anonymous class)::operator()(LogEntryPtr &) const: Code: 86. DB::HTTPException: Received error from remote server http://146b4357c08d:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Ftest%2F01165%2Ftest_13%2Frmt%2Freplicas%2F1&part=20250728_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.6.10636.altinitytest (altinity build)) '. (RECEIVED_ERROR_FROM_REMOTE_IO_SERVER), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.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 const&, int&&, String const&, unsigned long&&, String const&) @ 0x000000000feda8d9 4. /build/src/IO/HTTPCommon.cpp:104: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x000000000feda6e2 5. /build/src/IO/HTTPCommon.cpp:93: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x000000000feda537 6. /build/src/IO/ReadWriteBufferFromHTTP.cpp:277: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x000000001184a4c4 7. /build/src/IO/ReadWriteBufferFromHTTP.cpp:285: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x000000001184a615 8. /build/src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x000000001184ae59 9. /build/src/IO/ReadWriteBufferFromHTTP.cpp:472: void std::__function::__policy_invoker::__call_impl[abi:se190107]>(std::__function::__policy_storage const*) @ 0x000000001184cedd 10. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001184858b 11. /build/src/IO/ReadWriteBufferFromHTTP.cpp:465: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x000000001184bf0b 12. /build/src/IO/ReadBuffer.h:60: DB::ReadBuffer::next() @ 0x000000000a148c7b 13. /build/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) @ 0x0000000011849fb2 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]>&)>&, 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&) @ 0x0000000011841980 15. /build/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) @ 0x000000001621208e 16. /build/src/Storages/StorageReplicatedMergeTree.cpp:5228: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl[abi:se190107] const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000015f9a5fe 17. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000015ed8bfd 18. /build/src/Storages/StorageReplicatedMergeTree.cpp:2514: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x0000000015ec9aab 19. /build/src/Storages/StorageReplicatedMergeTree.cpp:2349: DB::StorageReplicatedMergeTree::executeLogEntry(DB::ReplicatedMergeTreeLogEntry&) @ 0x0000000015eba91b 20. /build/src/Storages/StorageReplicatedMergeTree.cpp:3876: bool std::__function::__policy_invoker&)>::__call_impl[abi:se190107])::$_1, bool (std::shared_ptr&)>>(std::__function::__policy_storage const*, std::shared_ptr&) @ 0x0000000015f9837e 21. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000165d6fc3 22. /build/src/Storages/StorageReplicatedMergeTree.cpp:3872: DB::StorageReplicatedMergeTree::processQueueEntry(std::shared_ptr) @ 0x0000000015efc18a 23. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001624c1b2 24. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000162f9c70 25. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x00000000162fa55a 26. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc6653 27. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000000fccc4c3 28. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc3d92 29. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fcca080 30. ? @ 0x00007fbc6213eac3 31. ? @ 0x00007fbc621d0850 (version 25.3.6.10636.altinitytest (altinity build)) 2025.07.28 12:00:21.328926 [ 17203 ] {} 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. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception>&, String>(int, FormatStringHelperImpl>&>::type, std::type_identity::type>, std::basic_string_view>&, String&&) @ 0x000000001385a5eb 4. /build/src/Access/SettingsConstraints.cpp:376: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000013859b18 5. /build/src/Access/SettingsConstraints.cpp:300: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000013858faf 6. /build/src/Access/SettingsConstraints.cpp:209: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000013859223 7. /build/src/Interpreters/Context.cpp:2690: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000014436134 8. /build/src/Interpreters/Context.cpp:2729: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x000000001443662b 9. /build/src/Server/HTTPHandler.cpp:457: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000001686d165 10. /build/src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x0000000016870807 11. /build/src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x0000000016907e99 12. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 13. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 14. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 15. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 16. ? @ 0x00007fbc6213eac3 17. ? @ 0x00007fbc621d0850 (version 25.3.6.10636.altinitytest (altinity build)) 2025.07.28 12:00:21.608724 [ 3960 ] {} test_13.rmt2 (7f9b740d-015c-470e-8cc6-8ba33be0dc63): auto DB::StorageReplicatedMergeTree::processQueueEntry(ReplicatedMergeTreeQueue::SelectedEntryPtr)::(anonymous class)::operator()(LogEntryPtr &) const: Code: 86. DB::HTTPException: Received error from remote server http://146b4357c08d:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Ftest%2F01165%2Ftest_13%2Frmt%2Freplicas%2F1&part=20250728_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.6.10636.altinitytest (altinity build)) '. (RECEIVED_ERROR_FROM_REMOTE_IO_SERVER), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.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 const&, int&&, String const&, unsigned long&&, String const&) @ 0x000000000feda8d9 4. /build/src/IO/HTTPCommon.cpp:104: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x000000000feda6e2 5. /build/src/IO/HTTPCommon.cpp:93: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x000000000feda537 6. /build/src/IO/ReadWriteBufferFromHTTP.cpp:277: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x000000001184a4c4 7. /build/src/IO/ReadWriteBufferFromHTTP.cpp:285: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x000000001184a615 8. /build/src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x000000001184ae59 9. /build/src/IO/ReadWriteBufferFromHTTP.cpp:472: void std::__function::__policy_invoker::__call_impl[abi:se190107]>(std::__function::__policy_storage const*) @ 0x000000001184cedd 10. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001184858b 11. /build/src/IO/ReadWriteBufferFromHTTP.cpp:465: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x000000001184bf0b 12. /build/src/IO/ReadBuffer.h:60: DB::ReadBuffer::next() @ 0x000000000a148c7b 13. /build/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) @ 0x0000000011849fb2 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]>&)>&, 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&) @ 0x0000000011841980 15. /build/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) @ 0x000000001621208e 16. /build/src/Storages/StorageReplicatedMergeTree.cpp:5228: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl[abi:se190107] const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000015f9a5fe 17. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000015ed8bfd 18. /build/src/Storages/StorageReplicatedMergeTree.cpp:2514: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x0000000015ec9aab 19. /build/src/Storages/StorageReplicatedMergeTree.cpp:2349: DB::StorageReplicatedMergeTree::executeLogEntry(DB::ReplicatedMergeTreeLogEntry&) @ 0x0000000015eba91b 20. /build/src/Storages/StorageReplicatedMergeTree.cpp:3876: bool std::__function::__policy_invoker&)>::__call_impl[abi:se190107])::$_1, bool (std::shared_ptr&)>>(std::__function::__policy_storage const*, std::shared_ptr&) @ 0x0000000015f9837e 21. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000165d6fc3 22. /build/src/Storages/StorageReplicatedMergeTree.cpp:3872: DB::StorageReplicatedMergeTree::processQueueEntry(std::shared_ptr) @ 0x0000000015efc18a 23. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001624c1b2 24. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000162f9c70 25. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x00000000162fa55a 26. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc6653 27. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000000fccc4c3 28. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc3d92 29. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fcca080 30. ? @ 0x00007fbc6213eac3 31. ? @ 0x00007fbc621d0850 (version 25.3.6.10636.altinitytest (altinity build)) 2025.07.28 12:00:21.676771 [ 17252 ] {34fe654d-48c2-40c8-a167-e016c32d5f18} executeQuery: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=0, jobs=0). (CANNOT_SCHEDULE_TASK) (version 25.3.6.10636.altinitytest (altinity build)) (from [::1]:33294) (comment: 02730_with_fill_by_sorting_prefix.sql) (query 26, line 47) (in query: -- DESC order in sorting prefix select * from ts order by sensor_id DESC, timestamp with fill from 6 step 1 interpolate (value as 9999);), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000fccaeeb 4. /build/src/Common/ThreadPool.cpp:275: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000fccc813 5. /build/src/Common/ThreadPool.cpp:323: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fcc7bbc 6. /build/src/Common/ThreadPool.cpp:494: ThreadPoolImpl>::scheduleOrThrowOnError(std::function, Priority) @ 0x000000000fcc7a0e 7. /build/src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::spawnThreadsImpl() @ 0x00000000169b2c0c 8. /build/src/Processors/Executors/PipelineExecutor.cpp:394: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x00000000169b0ba7 9. /build/src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x00000000169b03f4 10. /build/src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:se190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169bfeab 11. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc3d92 12. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fcca080 13. ? @ 0x00007fbc6213eac3 14. ? @ 0x00007fbc621d0850 2025.07.28 12:00:21.690806 [ 17252 ] {} 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. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000fccaeeb 4. /build/src/Common/ThreadPool.cpp:275: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000fccc813 5. /build/src/Common/ThreadPool.cpp:323: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fcc7bbc 6. /build/src/Common/ThreadPool.cpp:494: ThreadPoolImpl>::scheduleOrThrowOnError(std::function, Priority) @ 0x000000000fcc7a0e 7. /build/src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::spawnThreadsImpl() @ 0x00000000169b2c0c 8. /build/src/Processors/Executors/PipelineExecutor.cpp:394: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x00000000169b0ba7 9. /build/src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x00000000169b03f4 10. /build/src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:se190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169bfeab 11. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc3d92 12. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fcca080 13. ? @ 0x00007fbc6213eac3 14. ? @ 0x00007fbc621d0850 Job's origin stack trace: 0. /build/src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000000fc33b84 1. /build/src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000000fcc2ea7 2. /build/src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fcc535c 3. /build/src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000000fcc584d 4. /build/src/Common/ThreadPool.h:279: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x00000000169bf193 5. /build/src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x00000000169bf518 6. /build/src/Server/TCPHandler.cpp:1237: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x00000000168f1525 7. /build/src/Server/TCPHandler.cpp:678: DB::TCPHandler::runImpl() @ 0x00000000168e68e5 8. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 9. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 10. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 11. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 12. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 13. ? @ 0x00007fbc6213eac3 14. ? @ 0x00007fbc621d0850 2025.07.28 12:00:22.622238 [ 3964 ] {} test_13.rmt2 (7f9b740d-015c-470e-8cc6-8ba33be0dc63): auto DB::StorageReplicatedMergeTree::processQueueEntry(ReplicatedMergeTreeQueue::SelectedEntryPtr)::(anonymous class)::operator()(LogEntryPtr &) const: Code: 86. DB::HTTPException: Received error from remote server http://146b4357c08d:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Ftest%2F01165%2Ftest_13%2Frmt%2Freplicas%2F1&part=20250728_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.6.10636.altinitytest (altinity build)) '. (RECEIVED_ERROR_FROM_REMOTE_IO_SERVER), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.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 const&, int&&, String const&, unsigned long&&, String const&) @ 0x000000000feda8d9 4. /build/src/IO/HTTPCommon.cpp:104: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x000000000feda6e2 5. /build/src/IO/HTTPCommon.cpp:93: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x000000000feda537 6. /build/src/IO/ReadWriteBufferFromHTTP.cpp:277: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x000000001184a4c4 7. /build/src/IO/ReadWriteBufferFromHTTP.cpp:285: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x000000001184a615 8. /build/src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x000000001184ae59 9. /build/src/IO/ReadWriteBufferFromHTTP.cpp:472: void std::__function::__policy_invoker::__call_impl[abi:se190107]>(std::__function::__policy_storage const*) @ 0x000000001184cedd 10. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001184858b 11. /build/src/IO/ReadWriteBufferFromHTTP.cpp:465: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x000000001184bf0b 12. /build/src/IO/ReadBuffer.h:60: DB::ReadBuffer::next() @ 0x000000000a148c7b 13. /build/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) @ 0x0000000011849fb2 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]>&)>&, 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&) @ 0x0000000011841980 15. /build/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) @ 0x000000001621208e 16. /build/src/Storages/StorageReplicatedMergeTree.cpp:5228: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl[abi:se190107] const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000015f9a5fe 17. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000015ed8bfd 18. /build/src/Storages/StorageReplicatedMergeTree.cpp:2514: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x0000000015ec9aab 19. /build/src/Storages/StorageReplicatedMergeTree.cpp:2349: DB::StorageReplicatedMergeTree::executeLogEntry(DB::ReplicatedMergeTreeLogEntry&) @ 0x0000000015eba91b 20. /build/src/Storages/StorageReplicatedMergeTree.cpp:3876: bool std::__function::__policy_invoker&)>::__call_impl[abi:se190107])::$_1, bool (std::shared_ptr&)>>(std::__function::__policy_storage const*, std::shared_ptr&) @ 0x0000000015f9837e 21. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000165d6fc3 22. /build/src/Storages/StorageReplicatedMergeTree.cpp:3872: DB::StorageReplicatedMergeTree::processQueueEntry(std::shared_ptr) @ 0x0000000015efc18a 23. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001624c1b2 24. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000162f9c70 25. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x00000000162fa55a 26. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc6653 27. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000000fccc4c3 28. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc3d92 29. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fcca080 30. ? @ 0x00007fbc6213eac3 31. ? @ 0x00007fbc621d0850 (version 25.3.6.10636.altinitytest (altinity build)) 2025.07.28 12:00:22.893321 [ 7630 ] {0c642673-1a6c-4e45-a3df-dd6fb9f24cce} executeQuery: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=864, jobs=841). (CANNOT_SCHEDULE_TASK) (version 25.3.6.10636.altinitytest (altinity build)) (from [::1]:33228) (comment: 02274_full_sort_join_nodistinct.gen.sql) (query 164, line 238) (in query: SELECT t1.key, t2.key, length(t1.s), length(t2.s) FROM t1 AS t1 ALL INNER JOIN tn2 AS t2 ON t1.key == t2.key ORDER BY t1.key, t2.key;), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000fccaeeb 4. /build/src/Common/ThreadPool.cpp:275: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000fccacb3 5. /build/src/Common/ThreadPool.cpp:323: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fcc4ffc 6. /build/src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000000fcc584d 7. /build/src/Common/ThreadPool.h:279: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x00000000169bf193 8. /build/src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x00000000169bf518 9. /build/src/Server/TCPHandler.cpp:1237: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x00000000168f1525 10. /build/src/Server/TCPHandler.cpp:678: DB::TCPHandler::runImpl() @ 0x00000000168e68e5 11. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 12. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 13. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 14. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 15. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 16. ? @ 0x00007fbc6213eac3 17. ? @ 0x00007fbc621d0850 2025.07.28 12:00:22.907003 [ 7630 ] {} TCPHandler: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=864, jobs=841). (CANNOT_SCHEDULE_TASK), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000fccaeeb 4. /build/src/Common/ThreadPool.cpp:275: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000fccacb3 5. /build/src/Common/ThreadPool.cpp:323: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fcc4ffc 6. /build/src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000000fcc584d 7. /build/src/Common/ThreadPool.h:279: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x00000000169bf193 8. /build/src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x00000000169bf518 9. /build/src/Server/TCPHandler.cpp:1237: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x00000000168f1525 10. /build/src/Server/TCPHandler.cpp:678: DB::TCPHandler::runImpl() @ 0x00000000168e68e5 11. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 12. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 13. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 14. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 15. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 16. ? @ 0x00007fbc6213eac3 17. ? @ 0x00007fbc621d0850 2025.07.28 12:00:23.542758 [ 4446 ] {8ed9272c-517d-4302-a700-31a0dce61d98} executeQuery: Code: 48. DB::Exception: ALTER MODIFY QUERY is not supported by MergeTree engines family. (NOT_IMPLEMENTED) (version 25.3.6.10636.altinitytest (altinity build)) (from [::1]:59834) (comment: 02834_alter_exception.sql) (query 3, line 3) (in query: ALTER TABLE alter_02834 MODIFY QUERY SELECT a FROM alter_02834;), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000000a074fcb 4. /build/src/Storages/MergeTree/MergeTreeData.cpp:3687: DB::MergeTreeData::checkAlterIsPossible(DB::AlterCommands const&, std::shared_ptr) const @ 0x000000001633842f 5. /build/src/Interpreters/InterpreterAlterQuery.cpp:215: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x00000000148deab3 6. /build/src/Interpreters/InterpreterAlterQuery.cpp:77: DB::InterpreterAlterQuery::execute() @ 0x00000000148dcb0d 7. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88dc9 8. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 9. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 10. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 11. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 12. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 13. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 14. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 15. ? @ 0x00007fbc6213eac3 16. ? @ 0x00007fbc621d0850 2025.07.28 12:00:23.615434 [ 4446 ] {} TCPHandler: Code: 48. DB::Exception: ALTER MODIFY QUERY is not supported by MergeTree engines family. (NOT_IMPLEMENTED), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000000a074fcb 4. /build/src/Storages/MergeTree/MergeTreeData.cpp:3687: DB::MergeTreeData::checkAlterIsPossible(DB::AlterCommands const&, std::shared_ptr) const @ 0x000000001633842f 5. /build/src/Interpreters/InterpreterAlterQuery.cpp:215: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x00000000148deab3 6. /build/src/Interpreters/InterpreterAlterQuery.cpp:77: DB::InterpreterAlterQuery::execute() @ 0x00000000148dcb0d 7. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88dc9 8. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 9. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 10. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 11. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 12. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 13. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 14. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 15. ? @ 0x00007fbc6213eac3 16. ? @ 0x00007fbc621d0850 2025.07.28 12:00:23.658420 [ 17232 ] {} 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. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception>&, String>(int, FormatStringHelperImpl>&>::type, std::type_identity::type>, std::basic_string_view>&, String&&) @ 0x000000001385a5eb 4. /build/src/Access/SettingsConstraints.cpp:376: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000013859b18 5. /build/src/Access/SettingsConstraints.cpp:300: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000013858faf 6. /build/src/Access/SettingsConstraints.cpp:209: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000013859223 7. /build/src/Interpreters/Context.cpp:2690: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000014436134 8. /build/src/Interpreters/Context.cpp:2729: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x000000001443662b 9. /build/src/Server/HTTPHandler.cpp:457: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000001686d165 10. /build/src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x0000000016870807 11. /build/src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x0000000016907e99 12. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 13. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 14. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 15. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 16. ? @ 0x00007fbc6213eac3 17. ? @ 0x00007fbc621d0850 (version 25.3.6.10636.altinitytest (altinity build)) 2025.07.28 12:00:23.790429 [ 3966 ] {} test_13.rmt2 (7f9b740d-015c-470e-8cc6-8ba33be0dc63): auto DB::StorageReplicatedMergeTree::processQueueEntry(ReplicatedMergeTreeQueue::SelectedEntryPtr)::(anonymous class)::operator()(LogEntryPtr &) const: Code: 86. DB::HTTPException: Received error from remote server http://146b4357c08d:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Ftest%2F01165%2Ftest_13%2Frmt%2Freplicas%2F1&part=20250728_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.6.10636.altinitytest (altinity build)) '. (RECEIVED_ERROR_FROM_REMOTE_IO_SERVER), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.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 const&, int&&, String const&, unsigned long&&, String const&) @ 0x000000000feda8d9 4. /build/src/IO/HTTPCommon.cpp:104: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x000000000feda6e2 5. /build/src/IO/HTTPCommon.cpp:93: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x000000000feda537 6. /build/src/IO/ReadWriteBufferFromHTTP.cpp:277: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x000000001184a4c4 7. /build/src/IO/ReadWriteBufferFromHTTP.cpp:285: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x000000001184a615 8. /build/src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x000000001184ae59 9. /build/src/IO/ReadWriteBufferFromHTTP.cpp:472: void std::__function::__policy_invoker::__call_impl[abi:se190107]>(std::__function::__policy_storage const*) @ 0x000000001184cedd 10. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001184858b 11. /build/src/IO/ReadWriteBufferFromHTTP.cpp:465: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x000000001184bf0b 12. /build/src/IO/ReadBuffer.h:60: DB::ReadBuffer::next() @ 0x000000000a148c7b 13. /build/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) @ 0x0000000011849fb2 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]>&)>&, 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&) @ 0x0000000011841980 15. /build/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) @ 0x000000001621208e 16. /build/src/Storages/StorageReplicatedMergeTree.cpp:5228: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl[abi:se190107] const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000015f9a5fe 17. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000015ed8bfd 18. /build/src/Storages/StorageReplicatedMergeTree.cpp:2514: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x0000000015ec9aab 19. /build/src/Storages/StorageReplicatedMergeTree.cpp:2349: DB::StorageReplicatedMergeTree::executeLogEntry(DB::ReplicatedMergeTreeLogEntry&) @ 0x0000000015eba91b 20. /build/src/Storages/StorageReplicatedMergeTree.cpp:3876: bool std::__function::__policy_invoker&)>::__call_impl[abi:se190107])::$_1, bool (std::shared_ptr&)>>(std::__function::__policy_storage const*, std::shared_ptr&) @ 0x0000000015f9837e 21. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000165d6fc3 22. /build/src/Storages/StorageReplicatedMergeTree.cpp:3872: DB::StorageReplicatedMergeTree::processQueueEntry(std::shared_ptr) @ 0x0000000015efc18a 23. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001624c1b2 24. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000162f9c70 25. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x00000000162fa55a 26. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc6653 27. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000000fccc4c3 28. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc3d92 29. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fcca080 30. ? @ 0x00007fbc6213eac3 31. ? @ 0x00007fbc621d0850 (version 25.3.6.10636.altinitytest (altinity build)) 2025.07.28 12:00:24.826196 [ 4446 ] {571ddac8-1038-4a3d-b942-aebeaeb8c8a2} 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(5, 42, 42). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.6.10636.altinitytest (altinity build)) (from [::1]:59854) (comment: 02586_generate_random_structure.sql) (query 5, line 6) (in query: select generateRandomStructure(5, 42, 42);), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, unsigned long&&) @ 0x000000000a06f86b 4. /build/src/Functions/FunctionGenerateRandomStructure.cpp:371: DB::FunctionGenerateRandomStructure::getReturnTypeImpl(std::vector, std::allocator>> const&) const @ 0x000000000a075dd2 5. /build/src/Functions/IFunction.h:520: DB::IFunction::getReturnTypeImpl(std::vector> const&) const @ 0x000000000a06a2de 6. /build/src/Functions/IFunction.cpp:645: DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x0000000012d96b0c 7. /build/src/Functions/IFunction.cpp:577: DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x0000000012d9669c 8. /build/src/Functions/IFunction.cpp:606: DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x0000000012d96edc 9. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3544: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000014033cc9 10. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3838: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000014019a9e 11. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3980: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000014018e31 12. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:4304: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000014042fa7 13. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5605: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000014013749 14. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000140127f9 15. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000014011fce 16. /build/src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000001406ce8a 17. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000014973b42 18. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000001497268d 19. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000014974d24 20. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001492924b 21. /build/src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88641 22. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 23. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 24. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 25. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 26. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 27. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 28. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 29. ? @ 0x00007fbc6213eac3 30. ? @ 0x00007fbc621d0850 2025.07.28 12:00:24.829662 [ 4446 ] {} 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(5, 42, 42). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, unsigned long&&) @ 0x000000000a06f86b 4. /build/src/Functions/FunctionGenerateRandomStructure.cpp:371: DB::FunctionGenerateRandomStructure::getReturnTypeImpl(std::vector, std::allocator>> const&) const @ 0x000000000a075dd2 5. /build/src/Functions/IFunction.h:520: DB::IFunction::getReturnTypeImpl(std::vector> const&) const @ 0x000000000a06a2de 6. /build/src/Functions/IFunction.cpp:645: DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x0000000012d96b0c 7. /build/src/Functions/IFunction.cpp:577: DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x0000000012d9669c 8. /build/src/Functions/IFunction.cpp:606: DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x0000000012d96edc 9. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3544: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000014033cc9 10. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3838: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000014019a9e 11. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3980: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000014018e31 12. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:4304: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000014042fa7 13. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5605: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000014013749 14. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000140127f9 15. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000014011fce 16. /build/src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000001406ce8a 17. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000014973b42 18. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000001497268d 19. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000014974d24 20. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001492924b 21. /build/src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88641 22. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 23. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 24. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 25. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 26. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 27. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 28. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 29. ? @ 0x00007fbc6213eac3 30. ? @ 0x00007fbc621d0850 2025.07.28 12:00:24.856246 [ 3962 ] {} test_13.rmt2 (7f9b740d-015c-470e-8cc6-8ba33be0dc63): auto DB::StorageReplicatedMergeTree::processQueueEntry(ReplicatedMergeTreeQueue::SelectedEntryPtr)::(anonymous class)::operator()(LogEntryPtr &) const: Code: 86. DB::HTTPException: Received error from remote server http://146b4357c08d:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Ftest%2F01165%2Ftest_13%2Frmt%2Freplicas%2F1&part=20250728_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.6.10636.altinitytest (altinity build)) '. (RECEIVED_ERROR_FROM_REMOTE_IO_SERVER), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.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 const&, int&&, String const&, unsigned long&&, String const&) @ 0x000000000feda8d9 4. /build/src/IO/HTTPCommon.cpp:104: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x000000000feda6e2 5. /build/src/IO/HTTPCommon.cpp:93: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x000000000feda537 6. /build/src/IO/ReadWriteBufferFromHTTP.cpp:277: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x000000001184a4c4 7. /build/src/IO/ReadWriteBufferFromHTTP.cpp:285: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x000000001184a615 8. /build/src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x000000001184ae59 9. /build/src/IO/ReadWriteBufferFromHTTP.cpp:472: void std::__function::__policy_invoker::__call_impl[abi:se190107]>(std::__function::__policy_storage const*) @ 0x000000001184cedd 10. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001184858b 11. /build/src/IO/ReadWriteBufferFromHTTP.cpp:465: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x000000001184bf0b 12. /build/src/IO/ReadBuffer.h:60: DB::ReadBuffer::next() @ 0x000000000a148c7b 13. /build/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) @ 0x0000000011849fb2 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]>&)>&, 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&) @ 0x0000000011841980 15. /build/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) @ 0x000000001621208e 16. /build/src/Storages/StorageReplicatedMergeTree.cpp:5228: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl[abi:se190107] const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000015f9a5fe 17. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000015ed8bfd 18. /build/src/Storages/StorageReplicatedMergeTree.cpp:2514: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x0000000015ec9aab 19. /build/src/Storages/StorageReplicatedMergeTree.cpp:2349: DB::StorageReplicatedMergeTree::executeLogEntry(DB::ReplicatedMergeTreeLogEntry&) @ 0x0000000015eba91b 20. /build/src/Storages/StorageReplicatedMergeTree.cpp:3876: bool std::__function::__policy_invoker&)>::__call_impl[abi:se190107])::$_1, bool (std::shared_ptr&)>>(std::__function::__policy_storage const*, std::shared_ptr&) @ 0x0000000015f9837e 21. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000165d6fc3 22. /build/src/Storages/StorageReplicatedMergeTree.cpp:3872: DB::StorageReplicatedMergeTree::processQueueEntry(std::shared_ptr) @ 0x0000000015efc18a 23. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001624c1b2 24. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000162f9c70 25. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x00000000162fa55a 26. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc6653 27. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000000fccc4c3 28. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc3d92 29. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fcca080 30. ? @ 0x00007fbc6213eac3 31. ? @ 0x00007fbc621d0850 (version 25.3.6.10636.altinitytest (altinity build)) 2025.07.28 12:00:24.982355 [ 4446 ] {23859fc8-b350-4949-8499-0c423dcc7f62} executeQuery: Code: 43. DB::Exception: Illegal type String of the 1 argument of function generateRandomStructure, expected unsigned integer or Null: In scope SELECT generateRandomStructure('5'). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.6.10636.altinitytest (altinity build)) (from [::1]:59854) (comment: 02586_generate_random_structure.sql) (query 6, line 7) (in query: select generateRandomStructure('5');), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, unsigned long&&, String&&) @ 0x000000000a07984b 4. /build/src/Functions/FunctionGenerateRandomStructure.cpp:381: DB::FunctionGenerateRandomStructure::getReturnTypeImpl(std::vector, std::allocator>> const&) const @ 0x000000000a075ce0 5. /build/src/Functions/IFunction.h:520: DB::IFunction::getReturnTypeImpl(std::vector> const&) const @ 0x000000000a06a2de 6. /build/src/Functions/IFunction.cpp:645: DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x0000000012d96b0c 7. /build/src/Functions/IFunction.cpp:577: DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x0000000012d9669c 8. /build/src/Functions/IFunction.cpp:606: DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x0000000012d96edc 9. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3544: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000014033cc9 10. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3838: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000014019a9e 11. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3980: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000014018e31 12. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:4304: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000014042fa7 13. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5605: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000014013749 14. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000140127f9 15. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000014011fce 16. /build/src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000001406ce8a 17. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000014973b42 18. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000001497268d 19. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000014974d24 20. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001492924b 21. /build/src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88641 22. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 23. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 24. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 25. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 26. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 27. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 28. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 29. ? @ 0x00007fbc6213eac3 30. ? @ 0x00007fbc621d0850 2025.07.28 12:00:25.005331 [ 4446 ] {} TCPHandler: Code: 43. DB::Exception: Illegal type String of the 1 argument of function generateRandomStructure, expected unsigned integer or Null: In scope SELECT generateRandomStructure('5'). (ILLEGAL_TYPE_OF_ARGUMENT), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, unsigned long&&, String&&) @ 0x000000000a07984b 4. /build/src/Functions/FunctionGenerateRandomStructure.cpp:381: DB::FunctionGenerateRandomStructure::getReturnTypeImpl(std::vector, std::allocator>> const&) const @ 0x000000000a075ce0 5. /build/src/Functions/IFunction.h:520: DB::IFunction::getReturnTypeImpl(std::vector> const&) const @ 0x000000000a06a2de 6. /build/src/Functions/IFunction.cpp:645: DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x0000000012d96b0c 7. /build/src/Functions/IFunction.cpp:577: DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x0000000012d9669c 8. /build/src/Functions/IFunction.cpp:606: DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x0000000012d96edc 9. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3544: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000014033cc9 10. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3838: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000014019a9e 11. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3980: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000014018e31 12. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:4304: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000014042fa7 13. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5605: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000014013749 14. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000140127f9 15. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000014011fce 16. /build/src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000001406ce8a 17. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000014973b42 18. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000001497268d 19. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000014974d24 20. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001492924b 21. /build/src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88641 22. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 23. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 24. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 25. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 26. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 27. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 28. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 29. ? @ 0x00007fbc6213eac3 30. ? @ 0x00007fbc621d0850 2025.07.28 12:00:25.089822 [ 4446 ] {64538125-e512-41f5-8faa-ba59d806e817} executeQuery: Code: 43. DB::Exception: Illegal type String of the 2 argument of function generateRandomStructure, expected unsigned integer or Null: In scope SELECT generateRandomStructure(5, '42'). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.6.10636.altinitytest (altinity build)) (from [::1]:59854) (comment: 02586_generate_random_structure.sql) (query 7, line 8) (in query: select generateRandomStructure(5, '42');), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, unsigned long&&, String&&) @ 0x000000000a07984b 4. /build/src/Functions/FunctionGenerateRandomStructure.cpp:381: DB::FunctionGenerateRandomStructure::getReturnTypeImpl(std::vector, std::allocator>> const&) const @ 0x000000000a075ce0 5. /build/src/Functions/IFunction.h:520: DB::IFunction::getReturnTypeImpl(std::vector> const&) const @ 0x000000000a06a2de 6. /build/src/Functions/IFunction.cpp:645: DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x0000000012d96b0c 7. /build/src/Functions/IFunction.cpp:577: DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x0000000012d9669c 8. /build/src/Functions/IFunction.cpp:606: DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x0000000012d96edc 9. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3544: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000014033cc9 10. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3838: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000014019a9e 11. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3980: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000014018e31 12. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:4304: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000014042fa7 13. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5605: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000014013749 14. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000140127f9 15. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000014011fce 16. /build/src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000001406ce8a 17. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000014973b42 18. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000001497268d 19. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000014974d24 20. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001492924b 21. /build/src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88641 22. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 23. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 24. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 25. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 26. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 27. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 28. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 29. ? @ 0x00007fbc6213eac3 30. ? @ 0x00007fbc621d0850 2025.07.28 12:00:25.094275 [ 4446 ] {} TCPHandler: Code: 43. DB::Exception: Illegal type String of the 2 argument of function generateRandomStructure, expected unsigned integer or Null: In scope SELECT generateRandomStructure(5, '42'). (ILLEGAL_TYPE_OF_ARGUMENT), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, unsigned long&&, String&&) @ 0x000000000a07984b 4. /build/src/Functions/FunctionGenerateRandomStructure.cpp:381: DB::FunctionGenerateRandomStructure::getReturnTypeImpl(std::vector, std::allocator>> const&) const @ 0x000000000a075ce0 5. /build/src/Functions/IFunction.h:520: DB::IFunction::getReturnTypeImpl(std::vector> const&) const @ 0x000000000a06a2de 6. /build/src/Functions/IFunction.cpp:645: DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x0000000012d96b0c 7. /build/src/Functions/IFunction.cpp:577: DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x0000000012d9669c 8. /build/src/Functions/IFunction.cpp:606: DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x0000000012d96edc 9. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3544: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000014033cc9 10. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3838: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000014019a9e 11. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3980: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000014018e31 12. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:4304: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000014042fa7 13. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5605: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000014013749 14. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000140127f9 15. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000014011fce 16. /build/src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000001406ce8a 17. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000014973b42 18. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000001497268d 19. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000014974d24 20. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001492924b 21. /build/src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88641 22. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 23. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 24. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 25. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 26. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 27. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 28. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 29. ? @ 0x00007fbc6213eac3 30. ? @ 0x00007fbc621d0850 2025.07.28 12:00:25.158040 [ 4446 ] {e8918d81-fe29-404b-a489-c557fe493733} executeQuery: Code: 44. DB::Exception: Argument at index 0 for function generateRandomStructure must be constant. (ILLEGAL_COLUMN) (version 25.3.6.10636.altinitytest (altinity build)) (from [::1]:59854) (comment: 02586_generate_random_structure.sql) (query 8, line 9) (in query: select generateRandomStructure(materialize(5), 42);), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, unsigned long&, String&&) @ 0x000000000ba5db6b 4. /build/src/Functions/IFunction.cpp:141: DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d93178 5. /build/src/Functions/IFunction.cpp:343: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d93aad 6. /build/src/Functions/IFunction.cpp:420: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d95059 7. /build/src/Functions/IFunction.cpp:498: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d95c72 8. /build/src/Interpreters/ActionsDAG.cpp:812: DB::ActionsDAG::evaluatePartialResult(std::unordered_map, std::equal_to, std::allocator>>&, std::vector> const&, unsigned long, bool) @ 0x0000000013fa38cc 9. /build/src/Interpreters/ActionsDAG.cpp:892: DB::ActionsDAG::updateHeader(DB::Block const&) const @ 0x0000000013fa29a8 10. /build/src/Processors/Transforms/ExpressionTransform.cpp:10: DB::ExpressionTransform::transformHeader(DB::Block const&, DB::ActionsDAG const&) @ 0x0000000016c0afd2 11. /build/src/Processors/QueryPlan/ExpressionStep.cpp:38: DB::ExpressionStep::ExpressionStep(DB::Block const&, DB::ActionsDAG) @ 0x0000000016db8ad1 12. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107](DB::Block const&, DB::ActionsDAG&&) @ 0x00000000131ee01a 13. /build/src/Planner/Planner.cpp:392: DB::(anonymous namespace)::addExpressionStep(DB::QueryPlan&, std::shared_ptr&, String const&, std::unordered_set, std::hash>, std::equal_to>, std::allocator>>&) @ 0x000000001498191d 14. /build/src/Planner/Planner.cpp:1648: DB::Planner::buildPlanForQueryNode() @ 0x000000001497b7aa 15. /build/src/Planner/Planner.cpp:1308: DB::Planner::buildQueryPlanIfNeeded() @ 0x000000001497685c 16. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:255: DB::InterpreterSelectQueryAnalyzer::getQueryPlan() @ 0x000000001497476d 17. /build/src/Interpreters/executeQuery.cpp:1405: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88806 18. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 19. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 20. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 21. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 22. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 23. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 24. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 25. ? @ 0x00007fbc6213eac3 26. ? @ 0x00007fbc621d0850 2025.07.28 12:00:25.173110 [ 4446 ] {} TCPHandler: Code: 44. DB::Exception: Argument at index 0 for function generateRandomStructure must be constant. (ILLEGAL_COLUMN), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, unsigned long&, String&&) @ 0x000000000ba5db6b 4. /build/src/Functions/IFunction.cpp:141: DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d93178 5. /build/src/Functions/IFunction.cpp:343: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d93aad 6. /build/src/Functions/IFunction.cpp:420: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d95059 7. /build/src/Functions/IFunction.cpp:498: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d95c72 8. /build/src/Interpreters/ActionsDAG.cpp:812: DB::ActionsDAG::evaluatePartialResult(std::unordered_map, std::equal_to, std::allocator>>&, std::vector> const&, unsigned long, bool) @ 0x0000000013fa38cc 9. /build/src/Interpreters/ActionsDAG.cpp:892: DB::ActionsDAG::updateHeader(DB::Block const&) const @ 0x0000000013fa29a8 10. /build/src/Processors/Transforms/ExpressionTransform.cpp:10: DB::ExpressionTransform::transformHeader(DB::Block const&, DB::ActionsDAG const&) @ 0x0000000016c0afd2 11. /build/src/Processors/QueryPlan/ExpressionStep.cpp:38: DB::ExpressionStep::ExpressionStep(DB::Block const&, DB::ActionsDAG) @ 0x0000000016db8ad1 12. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107](DB::Block const&, DB::ActionsDAG&&) @ 0x00000000131ee01a 13. /build/src/Planner/Planner.cpp:392: DB::(anonymous namespace)::addExpressionStep(DB::QueryPlan&, std::shared_ptr&, String const&, std::unordered_set, std::hash>, std::equal_to>, std::allocator>>&) @ 0x000000001498191d 14. /build/src/Planner/Planner.cpp:1648: DB::Planner::buildPlanForQueryNode() @ 0x000000001497b7aa 15. /build/src/Planner/Planner.cpp:1308: DB::Planner::buildQueryPlanIfNeeded() @ 0x000000001497685c 16. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:255: DB::InterpreterSelectQueryAnalyzer::getQueryPlan() @ 0x000000001497476d 17. /build/src/Interpreters/executeQuery.cpp:1405: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88806 18. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 19. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 20. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 21. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 22. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 23. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 24. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 25. ? @ 0x00007fbc6213eac3 26. ? @ 0x00007fbc621d0850 2025.07.28 12:00:25.216111 [ 4446 ] {6d8a0157-64af-4e33-8dc3-5538079366a5} executeQuery: Code: 44. DB::Exception: Argument at index 1 for function generateRandomStructure must be constant. (ILLEGAL_COLUMN) (version 25.3.6.10636.altinitytest (altinity build)) (from [::1]:59854) (comment: 02586_generate_random_structure.sql) (query 9, line 10) (in query: select generateRandomStructure(5, materialize(42));), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, unsigned long&, String&&) @ 0x000000000ba5db6b 4. /build/src/Functions/IFunction.cpp:141: DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d93178 5. /build/src/Functions/IFunction.cpp:343: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d93aad 6. /build/src/Functions/IFunction.cpp:420: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d95059 7. /build/src/Functions/IFunction.cpp:498: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d95c72 8. /build/src/Interpreters/ActionsDAG.cpp:812: DB::ActionsDAG::evaluatePartialResult(std::unordered_map, std::equal_to, std::allocator>>&, std::vector> const&, unsigned long, bool) @ 0x0000000013fa38cc 9. /build/src/Interpreters/ActionsDAG.cpp:892: DB::ActionsDAG::updateHeader(DB::Block const&) const @ 0x0000000013fa29a8 10. /build/src/Processors/Transforms/ExpressionTransform.cpp:10: DB::ExpressionTransform::transformHeader(DB::Block const&, DB::ActionsDAG const&) @ 0x0000000016c0afd2 11. /build/src/Processors/QueryPlan/ExpressionStep.cpp:38: DB::ExpressionStep::ExpressionStep(DB::Block const&, DB::ActionsDAG) @ 0x0000000016db8ad1 12. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107](DB::Block const&, DB::ActionsDAG&&) @ 0x00000000131ee01a 13. /build/src/Planner/Planner.cpp:392: DB::(anonymous namespace)::addExpressionStep(DB::QueryPlan&, std::shared_ptr&, String const&, std::unordered_set, std::hash>, std::equal_to>, std::allocator>>&) @ 0x000000001498191d 14. /build/src/Planner/Planner.cpp:1648: DB::Planner::buildPlanForQueryNode() @ 0x000000001497b7aa 15. /build/src/Planner/Planner.cpp:1308: DB::Planner::buildQueryPlanIfNeeded() @ 0x000000001497685c 16. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:255: DB::InterpreterSelectQueryAnalyzer::getQueryPlan() @ 0x000000001497476d 17. /build/src/Interpreters/executeQuery.cpp:1405: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88806 18. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 19. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 20. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 21. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 22. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 23. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 24. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 25. ? @ 0x00007fbc6213eac3 26. ? @ 0x00007fbc621d0850 2025.07.28 12:00:25.230627 [ 4446 ] {} TCPHandler: Code: 44. DB::Exception: Argument at index 1 for function generateRandomStructure must be constant. (ILLEGAL_COLUMN), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, unsigned long&, String&&) @ 0x000000000ba5db6b 4. /build/src/Functions/IFunction.cpp:141: DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d93178 5. /build/src/Functions/IFunction.cpp:343: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d93aad 6. /build/src/Functions/IFunction.cpp:420: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d95059 7. /build/src/Functions/IFunction.cpp:498: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d95c72 8. /build/src/Interpreters/ActionsDAG.cpp:812: DB::ActionsDAG::evaluatePartialResult(std::unordered_map, std::equal_to, std::allocator>>&, std::vector> const&, unsigned long, bool) @ 0x0000000013fa38cc 9. /build/src/Interpreters/ActionsDAG.cpp:892: DB::ActionsDAG::updateHeader(DB::Block const&) const @ 0x0000000013fa29a8 10. /build/src/Processors/Transforms/ExpressionTransform.cpp:10: DB::ExpressionTransform::transformHeader(DB::Block const&, DB::ActionsDAG const&) @ 0x0000000016c0afd2 11. /build/src/Processors/QueryPlan/ExpressionStep.cpp:38: DB::ExpressionStep::ExpressionStep(DB::Block const&, DB::ActionsDAG) @ 0x0000000016db8ad1 12. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107](DB::Block const&, DB::ActionsDAG&&) @ 0x00000000131ee01a 13. /build/src/Planner/Planner.cpp:392: DB::(anonymous namespace)::addExpressionStep(DB::QueryPlan&, std::shared_ptr&, String const&, std::unordered_set, std::hash>, std::equal_to>, std::allocator>>&) @ 0x000000001498191d 14. /build/src/Planner/Planner.cpp:1648: DB::Planner::buildPlanForQueryNode() @ 0x000000001497b7aa 15. /build/src/Planner/Planner.cpp:1308: DB::Planner::buildQueryPlanIfNeeded() @ 0x000000001497685c 16. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:255: DB::InterpreterSelectQueryAnalyzer::getQueryPlan() @ 0x000000001497476d 17. /build/src/Interpreters/executeQuery.cpp:1405: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88806 18. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 19. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 20. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 21. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 22. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 23. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 24. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 25. ? @ 0x00007fbc6213eac3 26. ? @ 0x00007fbc621d0850 2025.07.28 12:00:25.507537 [ 3976 ] {} test_13.rmt2 (7f9b740d-015c-470e-8cc6-8ba33be0dc63): auto DB::StorageReplicatedMergeTree::processQueueEntry(ReplicatedMergeTreeQueue::SelectedEntryPtr)::(anonymous class)::operator()(LogEntryPtr &) const: Code: 86. DB::HTTPException: Received error from remote server http://146b4357c08d:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Ftest%2F01165%2Ftest_13%2Frmt%2Freplicas%2F1&part=20250728_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.6.10636.altinitytest (altinity build)) '. (RECEIVED_ERROR_FROM_REMOTE_IO_SERVER), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.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 const&, int&&, String const&, unsigned long&&, String const&) @ 0x000000000feda8d9 4. /build/src/IO/HTTPCommon.cpp:104: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x000000000feda6e2 5. /build/src/IO/HTTPCommon.cpp:93: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x000000000feda537 6. /build/src/IO/ReadWriteBufferFromHTTP.cpp:277: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x000000001184a4c4 7. /build/src/IO/ReadWriteBufferFromHTTP.cpp:285: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x000000001184a615 8. /build/src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x000000001184ae59 9. /build/src/IO/ReadWriteBufferFromHTTP.cpp:472: void std::__function::__policy_invoker::__call_impl[abi:se190107]>(std::__function::__policy_storage const*) @ 0x000000001184cedd 10. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001184858b 11. /build/src/IO/ReadWriteBufferFromHTTP.cpp:465: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x000000001184bf0b 12. /build/src/IO/ReadBuffer.h:60: DB::ReadBuffer::next() @ 0x000000000a148c7b 13. /build/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) @ 0x0000000011849fb2 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]>&)>&, 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&) @ 0x0000000011841980 15. /build/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) @ 0x000000001621208e 16. /build/src/Storages/StorageReplicatedMergeTree.cpp:5228: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl[abi:se190107] const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000015f9a5fe 17. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000015ed8bfd 18. /build/src/Storages/StorageReplicatedMergeTree.cpp:2514: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x0000000015ec9aab 19. /build/src/Storages/StorageReplicatedMergeTree.cpp:2349: DB::StorageReplicatedMergeTree::executeLogEntry(DB::ReplicatedMergeTreeLogEntry&) @ 0x0000000015eba91b 20. /build/src/Storages/StorageReplicatedMergeTree.cpp:3876: bool std::__function::__policy_invoker&)>::__call_impl[abi:se190107])::$_1, bool (std::shared_ptr&)>>(std::__function::__policy_storage const*, std::shared_ptr&) @ 0x0000000015f9837e 21. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000165d6fc3 22. /build/src/Storages/StorageReplicatedMergeTree.cpp:3872: DB::StorageReplicatedMergeTree::processQueueEntry(std::shared_ptr) @ 0x0000000015efc18a 23. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001624c1b2 24. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000162f9c70 25. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x00000000162fa55a 26. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc6653 27. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000000fccc4c3 28. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc3d92 29. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fcca080 30. ? @ 0x00007fbc6213eac3 31. ? @ 0x00007fbc621d0850 (version 25.3.6.10636.altinitytest (altinity build)) 2025.07.28 12:00:26.065368 [ 4446 ] {e7307eea-f165-4d49-a92a-147e33114ada} executeQuery: Code: 42. DB::Exception: Table function 'generateRandom' requires at most four (or three if structure is missing) arguments: [structure, random_seed, max_string_length, max_array_length]. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.6.10636.altinitytest (altinity build)) (from [::1]:59854) (comment: 02586_generate_random_structure.sql) (query 14, line 16) (in query: select * from generateRandom(10000000, 2, 2, 2) limit 1;), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x000000000a06b56b 4. /build/src/TableFunctions/TableFunctionGenerateRandom.cpp:79: DB::(anonymous namespace)::TableFunctionGenerateRandom::parseArguments(std::shared_ptr const&, std::shared_ptr) @ 0x0000000011831e78 5. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:4834: DB::QueryAnalyzer::resolveTableFunction(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&, bool) @ 0x000000001401cb85 6. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5342: DB::QueryAnalyzer::resolveQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&) @ 0x00000000140452bf 7. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5597: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000140136f0 8. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000140127f9 9. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000014011fce 10. /build/src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000001406ce8a 11. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000014973b42 12. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000001497268d 13. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000014974d24 14. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001492924b 15. /build/src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88641 16. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 17. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 18. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 19. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 20. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 21. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 22. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 23. ? @ 0x00007fbc6213eac3 24. ? @ 0x00007fbc621d0850 2025.07.28 12:00:26.085243 [ 4446 ] {} TCPHandler: Code: 42. DB::Exception: Table function 'generateRandom' requires at most four (or three if structure is missing) arguments: [structure, random_seed, max_string_length, max_array_length]. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x000000000a06b56b 4. /build/src/TableFunctions/TableFunctionGenerateRandom.cpp:79: DB::(anonymous namespace)::TableFunctionGenerateRandom::parseArguments(std::shared_ptr const&, std::shared_ptr) @ 0x0000000011831e78 5. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:4834: DB::QueryAnalyzer::resolveTableFunction(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&, bool) @ 0x000000001401cb85 6. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5342: DB::QueryAnalyzer::resolveQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&) @ 0x00000000140452bf 7. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5597: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000140136f0 8. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000140127f9 9. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000014011fce 10. /build/src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000001406ce8a 11. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000014973b42 12. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000001497268d 13. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000014974d24 14. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001492924b 15. /build/src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88641 16. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 17. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 18. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 19. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 20. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 21. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 22. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 23. ? @ 0x00007fbc6213eac3 24. ? @ 0x00007fbc621d0850 2025.07.28 12:00:26.461320 [ 3970 ] {} test_13.rmt2 (7f9b740d-015c-470e-8cc6-8ba33be0dc63): auto DB::StorageReplicatedMergeTree::processQueueEntry(ReplicatedMergeTreeQueue::SelectedEntryPtr)::(anonymous class)::operator()(LogEntryPtr &) const: Code: 86. DB::HTTPException: Received error from remote server http://146b4357c08d:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Ftest%2F01165%2Ftest_13%2Frmt%2Freplicas%2F1&part=20250728_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.6.10636.altinitytest (altinity build)) '. (RECEIVED_ERROR_FROM_REMOTE_IO_SERVER), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.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 const&, int&&, String const&, unsigned long&&, String const&) @ 0x000000000feda8d9 4. /build/src/IO/HTTPCommon.cpp:104: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x000000000feda6e2 5. /build/src/IO/HTTPCommon.cpp:93: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x000000000feda537 6. /build/src/IO/ReadWriteBufferFromHTTP.cpp:277: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x000000001184a4c4 7. /build/src/IO/ReadWriteBufferFromHTTP.cpp:285: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x000000001184a615 8. /build/src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x000000001184ae59 9. /build/src/IO/ReadWriteBufferFromHTTP.cpp:472: void std::__function::__policy_invoker::__call_impl[abi:se190107]>(std::__function::__policy_storage const*) @ 0x000000001184cedd 10. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001184858b 11. /build/src/IO/ReadWriteBufferFromHTTP.cpp:465: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x000000001184bf0b 12. /build/src/IO/ReadBuffer.h:60: DB::ReadBuffer::next() @ 0x000000000a148c7b 13. /build/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) @ 0x0000000011849fb2 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]>&)>&, 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&) @ 0x0000000011841980 15. /build/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) @ 0x000000001621208e 16. /build/src/Storages/StorageReplicatedMergeTree.cpp:5228: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl[abi:se190107] const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000015f9a5fe 17. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000015ed8bfd 18. /build/src/Storages/StorageReplicatedMergeTree.cpp:2514: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x0000000015ec9aab 19. /build/src/Storages/StorageReplicatedMergeTree.cpp:2349: DB::StorageReplicatedMergeTree::executeLogEntry(DB::ReplicatedMergeTreeLogEntry&) @ 0x0000000015eba91b 20. /build/src/Storages/StorageReplicatedMergeTree.cpp:3876: bool std::__function::__policy_invoker&)>::__call_impl[abi:se190107])::$_1, bool (std::shared_ptr&)>>(std::__function::__policy_storage const*, std::shared_ptr&) @ 0x0000000015f9837e 21. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000165d6fc3 22. /build/src/Storages/StorageReplicatedMergeTree.cpp:3872: DB::StorageReplicatedMergeTree::processQueueEntry(std::shared_ptr) @ 0x0000000015efc18a 23. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001624c1b2 24. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000162f9c70 25. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x00000000162fa55a 26. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc6653 27. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000000fccc4c3 28. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc3d92 29. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fcca080 30. ? @ 0x00007fbc6213eac3 31. ? @ 0x00007fbc621d0850 (version 25.3.6.10636.altinitytest (altinity build)) 2025.07.28 12:00:26.981435 [ 17371 ] {b1416a30-bae4-428f-97fe-097ea0cb1afe} executeQuery: Code: 471. DB::Exception: Invalid value '0' for max_read_buffer_size. (INVALID_SETTING_VALUE) (version 25.3.6.10636.altinitytest (altinity build)) (from [::1]:59890) (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. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type>, unsigned long const&) @ 0x000000000a951dcb 4. /build/src/Interpreters/Context.cpp:6171: DB::Context::getReadSettings() const @ 0x0000000014450b39 5. /build/src/Processors/QueryPlan/ReadFromMergeTree.cpp:211: DB::getMergeTreeReaderSettings(std::shared_ptr const&, DB::SelectQueryInfo const&) @ 0x0000000016e1d3ba 6. /build/src/Processors/QueryPlan/ReadFromMergeTree.cpp:351: 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) @ 0x0000000016e1c90b 7. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107], 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&) @ 0x0000000016401cd2 8. /build/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 @ 0x00000000163ec114 9. /build/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 @ 0x00000000163ebef8 10. /build/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) @ 0x0000000016635568 11. /build/src/Planner/PlannerJoinTree.cpp:946: DB::(anonymous namespace)::buildQueryPlanForTableExpression(std::shared_ptr, std::shared_ptr const&, DB::SelectQueryInfo const&, DB::SelectQueryOptions const&, std::shared_ptr&, bool, bool) @ 0x00000000149970ee 12. /build/src/Planner/PlannerJoinTree.cpp:2252: DB::buildJoinTreeQueryPlan(std::shared_ptr const&, DB::SelectQueryInfo const&, DB::SelectQueryOptions&, std::unordered_set, std::equal_to, std::allocator> const&, std::shared_ptr&) @ 0x000000001498e109 13. /build/src/Planner/Planner.cpp:1553: DB::Planner::buildPlanForQueryNode() @ 0x0000000014979dae 14. /build/src/Planner/Planner.cpp:1308: DB::Planner::buildQueryPlanIfNeeded() @ 0x000000001497685c 15. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:255: DB::InterpreterSelectQueryAnalyzer::getQueryPlan() @ 0x000000001497476d 16. /build/src/Interpreters/executeQuery.cpp:1405: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88806 17. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 18. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 19. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 20. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 21. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 22. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 23. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 24. ? @ 0x00007fbc6213eac3 25. ? @ 0x00007fbc621d0850 2025.07.28 12:00:26.984867 [ 17371 ] {} 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. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type>, unsigned long const&) @ 0x000000000a951dcb 4. /build/src/Interpreters/Context.cpp:6171: DB::Context::getReadSettings() const @ 0x0000000014450b39 5. /build/src/Processors/QueryPlan/ReadFromMergeTree.cpp:211: DB::getMergeTreeReaderSettings(std::shared_ptr const&, DB::SelectQueryInfo const&) @ 0x0000000016e1d3ba 6. /build/src/Processors/QueryPlan/ReadFromMergeTree.cpp:351: 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) @ 0x0000000016e1c90b 7. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107], 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&) @ 0x0000000016401cd2 8. /build/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 @ 0x00000000163ec114 9. /build/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 @ 0x00000000163ebef8 10. /build/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) @ 0x0000000016635568 11. /build/src/Planner/PlannerJoinTree.cpp:946: DB::(anonymous namespace)::buildQueryPlanForTableExpression(std::shared_ptr, std::shared_ptr const&, DB::SelectQueryInfo const&, DB::SelectQueryOptions const&, std::shared_ptr&, bool, bool) @ 0x00000000149970ee 12. /build/src/Planner/PlannerJoinTree.cpp:2252: DB::buildJoinTreeQueryPlan(std::shared_ptr const&, DB::SelectQueryInfo const&, DB::SelectQueryOptions&, std::unordered_set, std::equal_to, std::allocator> const&, std::shared_ptr&) @ 0x000000001498e109 13. /build/src/Planner/Planner.cpp:1553: DB::Planner::buildPlanForQueryNode() @ 0x0000000014979dae 14. /build/src/Planner/Planner.cpp:1308: DB::Planner::buildQueryPlanIfNeeded() @ 0x000000001497685c 15. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:255: DB::InterpreterSelectQueryAnalyzer::getQueryPlan() @ 0x000000001497476d 16. /build/src/Interpreters/executeQuery.cpp:1405: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88806 17. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 18. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 19. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 20. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 21. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 22. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 23. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 24. ? @ 0x00007fbc6213eac3 25. ? @ 0x00007fbc621d0850 2025.07.28 12:00:27.387812 [ 3972 ] {} test_13.rmt2 (7f9b740d-015c-470e-8cc6-8ba33be0dc63): auto DB::StorageReplicatedMergeTree::processQueueEntry(ReplicatedMergeTreeQueue::SelectedEntryPtr)::(anonymous class)::operator()(LogEntryPtr &) const: Code: 86. DB::HTTPException: Received error from remote server http://146b4357c08d:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Ftest%2F01165%2Ftest_13%2Frmt%2Freplicas%2F1&part=20250728_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.6.10636.altinitytest (altinity build)) '. (RECEIVED_ERROR_FROM_REMOTE_IO_SERVER), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.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 const&, int&&, String const&, unsigned long&&, String const&) @ 0x000000000feda8d9 4. /build/src/IO/HTTPCommon.cpp:104: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x000000000feda6e2 5. /build/src/IO/HTTPCommon.cpp:93: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x000000000feda537 6. /build/src/IO/ReadWriteBufferFromHTTP.cpp:277: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x000000001184a4c4 7. /build/src/IO/ReadWriteBufferFromHTTP.cpp:285: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x000000001184a615 8. /build/src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x000000001184ae59 9. /build/src/IO/ReadWriteBufferFromHTTP.cpp:472: void std::__function::__policy_invoker::__call_impl[abi:se190107]>(std::__function::__policy_storage const*) @ 0x000000001184cedd 10. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001184858b 11. /build/src/IO/ReadWriteBufferFromHTTP.cpp:465: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x000000001184bf0b 12. /build/src/IO/ReadBuffer.h:60: DB::ReadBuffer::next() @ 0x000000000a148c7b 13. /build/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) @ 0x0000000011849fb2 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]>&)>&, 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&) @ 0x0000000011841980 15. /build/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) @ 0x000000001621208e 16. /build/src/Storages/StorageReplicatedMergeTree.cpp:5228: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl[abi:se190107] const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000015f9a5fe 17. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000015ed8bfd 18. /build/src/Storages/StorageReplicatedMergeTree.cpp:2514: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x0000000015ec9aab 19. /build/src/Storages/StorageReplicatedMergeTree.cpp:2349: DB::StorageReplicatedMergeTree::executeLogEntry(DB::ReplicatedMergeTreeLogEntry&) @ 0x0000000015eba91b 20. /build/src/Storages/StorageReplicatedMergeTree.cpp:3876: bool std::__function::__policy_invoker&)>::__call_impl[abi:se190107])::$_1, bool (std::shared_ptr&)>>(std::__function::__policy_storage const*, std::shared_ptr&) @ 0x0000000015f9837e 21. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000165d6fc3 22. /build/src/Storages/StorageReplicatedMergeTree.cpp:3872: DB::StorageReplicatedMergeTree::processQueueEntry(std::shared_ptr) @ 0x0000000015efc18a 23. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001624c1b2 24. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000162f9c70 25. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x00000000162fa55a 26. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc6653 27. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000000fccc4c3 28. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc3d92 29. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fcca080 30. ? @ 0x00007fbc6213eac3 31. ? @ 0x00007fbc621d0850 (version 25.3.6.10636.altinitytest (altinity build)) 2025.07.28 12:00:27.741159 [ 17371 ] {b084687e-948c-47d4-8636-99209fe2ca70} executeQuery: Code: 471. DB::Exception: Invalid value '0' for max_read_buffer_size. (INVALID_SETTING_VALUE) (version 25.3.6.10636.altinitytest (altinity build)) (from [::1]:59890) (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. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type>, unsigned long const&) @ 0x000000000a951dcb 4. /build/src/Interpreters/Context.cpp:6171: DB::Context::getReadSettings() const @ 0x0000000014450b39 5. /build/src/Processors/QueryPlan/ReadFromMergeTree.cpp:211: DB::getMergeTreeReaderSettings(std::shared_ptr const&, DB::SelectQueryInfo const&) @ 0x0000000016e1d3ba 6. /build/src/Processors/QueryPlan/ReadFromMergeTree.cpp:351: 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) @ 0x0000000016e1c90b 7. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107], 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&) @ 0x0000000016401cd2 8. /build/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 @ 0x00000000163ec114 9. /build/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 @ 0x00000000163ebef8 10. /build/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) @ 0x0000000016635568 11. /build/src/Planner/PlannerJoinTree.cpp:946: DB::(anonymous namespace)::buildQueryPlanForTableExpression(std::shared_ptr, std::shared_ptr const&, DB::SelectQueryInfo const&, DB::SelectQueryOptions const&, std::shared_ptr&, bool, bool) @ 0x00000000149970ee 12. /build/src/Planner/PlannerJoinTree.cpp:2252: DB::buildJoinTreeQueryPlan(std::shared_ptr const&, DB::SelectQueryInfo const&, DB::SelectQueryOptions&, std::unordered_set, std::equal_to, std::allocator> const&, std::shared_ptr&) @ 0x000000001498e109 13. /build/src/Planner/Planner.cpp:1553: DB::Planner::buildPlanForQueryNode() @ 0x0000000014979dae 14. /build/src/Planner/Planner.cpp:1308: DB::Planner::buildQueryPlanIfNeeded() @ 0x000000001497685c 15. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:255: DB::InterpreterSelectQueryAnalyzer::getQueryPlan() @ 0x000000001497476d 16. /build/src/Interpreters/executeQuery.cpp:1405: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88806 17. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 18. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 19. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 20. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 21. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 22. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 23. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 24. ? @ 0x00007fbc6213eac3 25. ? @ 0x00007fbc621d0850 2025.07.28 12:00:27.752473 [ 17371 ] {} 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. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type>, unsigned long const&) @ 0x000000000a951dcb 4. /build/src/Interpreters/Context.cpp:6171: DB::Context::getReadSettings() const @ 0x0000000014450b39 5. /build/src/Processors/QueryPlan/ReadFromMergeTree.cpp:211: DB::getMergeTreeReaderSettings(std::shared_ptr const&, DB::SelectQueryInfo const&) @ 0x0000000016e1d3ba 6. /build/src/Processors/QueryPlan/ReadFromMergeTree.cpp:351: 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) @ 0x0000000016e1c90b 7. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107], 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&) @ 0x0000000016401cd2 8. /build/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 @ 0x00000000163ec114 9. /build/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 @ 0x00000000163ebef8 10. /build/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) @ 0x0000000016635568 11. /build/src/Planner/PlannerJoinTree.cpp:946: DB::(anonymous namespace)::buildQueryPlanForTableExpression(std::shared_ptr, std::shared_ptr const&, DB::SelectQueryInfo const&, DB::SelectQueryOptions const&, std::shared_ptr&, bool, bool) @ 0x00000000149970ee 12. /build/src/Planner/PlannerJoinTree.cpp:2252: DB::buildJoinTreeQueryPlan(std::shared_ptr const&, DB::SelectQueryInfo const&, DB::SelectQueryOptions&, std::unordered_set, std::equal_to, std::allocator> const&, std::shared_ptr&) @ 0x000000001498e109 13. /build/src/Planner/Planner.cpp:1553: DB::Planner::buildPlanForQueryNode() @ 0x0000000014979dae 14. /build/src/Planner/Planner.cpp:1308: DB::Planner::buildQueryPlanIfNeeded() @ 0x000000001497685c 15. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:255: DB::InterpreterSelectQueryAnalyzer::getQueryPlan() @ 0x000000001497476d 16. /build/src/Interpreters/executeQuery.cpp:1405: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88806 17. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 18. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 19. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 20. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 21. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 22. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 23. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 24. ? @ 0x00007fbc6213eac3 25. ? @ 0x00007fbc621d0850 2025.07.28 12:00:27.778489 [ 3967 ] {} test_13.rmt2 (7f9b740d-015c-470e-8cc6-8ba33be0dc63): auto DB::StorageReplicatedMergeTree::processQueueEntry(ReplicatedMergeTreeQueue::SelectedEntryPtr)::(anonymous class)::operator()(LogEntryPtr &) const: Code: 86. DB::HTTPException: Received error from remote server http://146b4357c08d:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Ftest%2F01165%2Ftest_13%2Frmt%2Freplicas%2F1&part=20250728_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.6.10636.altinitytest (altinity build)) '. (RECEIVED_ERROR_FROM_REMOTE_IO_SERVER), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.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 const&, int&&, String const&, unsigned long&&, String const&) @ 0x000000000feda8d9 4. /build/src/IO/HTTPCommon.cpp:104: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x000000000feda6e2 5. /build/src/IO/HTTPCommon.cpp:93: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x000000000feda537 6. /build/src/IO/ReadWriteBufferFromHTTP.cpp:277: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x000000001184a4c4 7. /build/src/IO/ReadWriteBufferFromHTTP.cpp:285: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x000000001184a615 8. /build/src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x000000001184ae59 9. /build/src/IO/ReadWriteBufferFromHTTP.cpp:472: void std::__function::__policy_invoker::__call_impl[abi:se190107]>(std::__function::__policy_storage const*) @ 0x000000001184cedd 10. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001184858b 11. /build/src/IO/ReadWriteBufferFromHTTP.cpp:465: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x000000001184bf0b 12. /build/src/IO/ReadBuffer.h:60: DB::ReadBuffer::next() @ 0x000000000a148c7b 13. /build/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) @ 0x0000000011849fb2 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]>&)>&, 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&) @ 0x0000000011841980 15. /build/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) @ 0x000000001621208e 16. /build/src/Storages/StorageReplicatedMergeTree.cpp:5228: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl[abi:se190107] const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000015f9a5fe 17. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000015ed8bfd 18. /build/src/Storages/StorageReplicatedMergeTree.cpp:2514: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x0000000015ec9aab 19. /build/src/Storages/StorageReplicatedMergeTree.cpp:2349: DB::StorageReplicatedMergeTree::executeLogEntry(DB::ReplicatedMergeTreeLogEntry&) @ 0x0000000015eba91b 20. /build/src/Storages/StorageReplicatedMergeTree.cpp:3876: bool std::__function::__policy_invoker&)>::__call_impl[abi:se190107])::$_1, bool (std::shared_ptr&)>>(std::__function::__policy_storage const*, std::shared_ptr&) @ 0x0000000015f9837e 21. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000165d6fc3 22. /build/src/Storages/StorageReplicatedMergeTree.cpp:3872: DB::StorageReplicatedMergeTree::processQueueEntry(std::shared_ptr) @ 0x0000000015efc18a 23. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001624c1b2 24. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000162f9c70 25. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x00000000162fa55a 26. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc6653 27. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000000fccc4c3 28. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc3d92 29. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fcca080 30. ? @ 0x00007fbc6213eac3 31. ? @ 0x00007fbc621d0850 (version 25.3.6.10636.altinitytest (altinity build)) 2025.07.28 12:00:28.115881 [ 3968 ] {} test_13.rmt2 (7f9b740d-015c-470e-8cc6-8ba33be0dc63): auto DB::StorageReplicatedMergeTree::processQueueEntry(ReplicatedMergeTreeQueue::SelectedEntryPtr)::(anonymous class)::operator()(LogEntryPtr &) const: Code: 86. DB::HTTPException: Received error from remote server http://146b4357c08d:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Ftest%2F01165%2Ftest_13%2Frmt%2Freplicas%2F1&part=20250728_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.6.10636.altinitytest (altinity build)) '. (RECEIVED_ERROR_FROM_REMOTE_IO_SERVER), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.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 const&, int&&, String const&, unsigned long&&, String const&) @ 0x000000000feda8d9 4. /build/src/IO/HTTPCommon.cpp:104: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x000000000feda6e2 5. /build/src/IO/HTTPCommon.cpp:93: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x000000000feda537 6. /build/src/IO/ReadWriteBufferFromHTTP.cpp:277: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x000000001184a4c4 7. /build/src/IO/ReadWriteBufferFromHTTP.cpp:285: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x000000001184a615 8. /build/src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x000000001184ae59 9. /build/src/IO/ReadWriteBufferFromHTTP.cpp:472: void std::__function::__policy_invoker::__call_impl[abi:se190107]>(std::__function::__policy_storage const*) @ 0x000000001184cedd 10. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001184858b 11. /build/src/IO/ReadWriteBufferFromHTTP.cpp:465: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x000000001184bf0b 12. /build/src/IO/ReadBuffer.h:60: DB::ReadBuffer::next() @ 0x000000000a148c7b 13. /build/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) @ 0x0000000011849fb2 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]>&)>&, 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&) @ 0x0000000011841980 15. /build/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) @ 0x000000001621208e 16. /build/src/Storages/StorageReplicatedMergeTree.cpp:5228: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl[abi:se190107] const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000015f9a5fe 17. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000015ed8bfd 18. /build/src/Storages/StorageReplicatedMergeTree.cpp:2514: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x0000000015ec9aab 19. /build/src/Storages/StorageReplicatedMergeTree.cpp:2349: DB::StorageReplicatedMergeTree::executeLogEntry(DB::ReplicatedMergeTreeLogEntry&) @ 0x0000000015eba91b 20. /build/src/Storages/StorageReplicatedMergeTree.cpp:3876: bool std::__function::__policy_invoker&)>::__call_impl[abi:se190107])::$_1, bool (std::shared_ptr&)>>(std::__function::__policy_storage const*, std::shared_ptr&) @ 0x0000000015f9837e 21. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000165d6fc3 22. /build/src/Storages/StorageReplicatedMergeTree.cpp:3872: DB::StorageReplicatedMergeTree::processQueueEntry(std::shared_ptr) @ 0x0000000015efc18a 23. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001624c1b2 24. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000162f9c70 25. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x00000000162fa55a 26. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc6653 27. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000000fccc4c3 28. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc3d92 29. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fcca080 30. ? @ 0x00007fbc6213eac3 31. ? @ 0x00007fbc621d0850 (version 25.3.6.10636.altinitytest (altinity build)) 2025.07.28 12:00:28.322536 [ 17371 ] {5025f9cd-5b40-40ad-b866-41ee7a77ffe7} executeQuery: Code: 471. DB::Exception: Invalid value '0' for max_read_buffer_size. (INVALID_SETTING_VALUE) (version 25.3.6.10636.altinitytest (altinity build)) (from [::1]:59890) (comment: 02052_last_granula_adjust_logical_error.gen.sql) (query 14, line 45) (in query: select * apply max from data_02052_10_wide0 settings max_read_buffer_size=0, max_threads=1;), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type>, unsigned long const&) @ 0x000000000a951dcb 4. /build/src/Interpreters/Context.cpp:6171: DB::Context::getReadSettings() const @ 0x0000000014450b39 5. /build/src/Processors/QueryPlan/ReadFromMergeTree.cpp:211: DB::getMergeTreeReaderSettings(std::shared_ptr const&, DB::SelectQueryInfo const&) @ 0x0000000016e1d3ba 6. /build/src/Processors/QueryPlan/ReadFromMergeTree.cpp:351: 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) @ 0x0000000016e1c90b 7. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107], 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&) @ 0x0000000016401cd2 8. /build/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 @ 0x00000000163ec114 9. /build/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 @ 0x00000000163ebef8 10. /build/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) @ 0x0000000016635568 11. /build/src/Planner/PlannerJoinTree.cpp:946: DB::(anonymous namespace)::buildQueryPlanForTableExpression(std::shared_ptr, std::shared_ptr const&, DB::SelectQueryInfo const&, DB::SelectQueryOptions const&, std::shared_ptr&, bool, bool) @ 0x00000000149970ee 12. /build/src/Planner/PlannerJoinTree.cpp:2252: DB::buildJoinTreeQueryPlan(std::shared_ptr const&, DB::SelectQueryInfo const&, DB::SelectQueryOptions&, std::unordered_set, std::equal_to, std::allocator> const&, std::shared_ptr&) @ 0x000000001498e109 13. /build/src/Planner/Planner.cpp:1553: DB::Planner::buildPlanForQueryNode() @ 0x0000000014979dae 14. /build/src/Planner/Planner.cpp:1308: DB::Planner::buildQueryPlanIfNeeded() @ 0x000000001497685c 15. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:255: DB::InterpreterSelectQueryAnalyzer::getQueryPlan() @ 0x000000001497476d 16. /build/src/Interpreters/executeQuery.cpp:1405: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88806 17. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 18. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 19. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 20. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 21. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 22. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 23. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 24. ? @ 0x00007fbc6213eac3 25. ? @ 0x00007fbc621d0850 2025.07.28 12:00:28.325253 [ 17371 ] {} 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. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type>, unsigned long const&) @ 0x000000000a951dcb 4. /build/src/Interpreters/Context.cpp:6171: DB::Context::getReadSettings() const @ 0x0000000014450b39 5. /build/src/Processors/QueryPlan/ReadFromMergeTree.cpp:211: DB::getMergeTreeReaderSettings(std::shared_ptr const&, DB::SelectQueryInfo const&) @ 0x0000000016e1d3ba 6. /build/src/Processors/QueryPlan/ReadFromMergeTree.cpp:351: 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) @ 0x0000000016e1c90b 7. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107], 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&) @ 0x0000000016401cd2 8. /build/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 @ 0x00000000163ec114 9. /build/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 @ 0x00000000163ebef8 10. /build/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) @ 0x0000000016635568 11. /build/src/Planner/PlannerJoinTree.cpp:946: DB::(anonymous namespace)::buildQueryPlanForTableExpression(std::shared_ptr, std::shared_ptr const&, DB::SelectQueryInfo const&, DB::SelectQueryOptions const&, std::shared_ptr&, bool, bool) @ 0x00000000149970ee 12. /build/src/Planner/PlannerJoinTree.cpp:2252: DB::buildJoinTreeQueryPlan(std::shared_ptr const&, DB::SelectQueryInfo const&, DB::SelectQueryOptions&, std::unordered_set, std::equal_to, std::allocator> const&, std::shared_ptr&) @ 0x000000001498e109 13. /build/src/Planner/Planner.cpp:1553: DB::Planner::buildPlanForQueryNode() @ 0x0000000014979dae 14. /build/src/Planner/Planner.cpp:1308: DB::Planner::buildQueryPlanIfNeeded() @ 0x000000001497685c 15. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:255: DB::InterpreterSelectQueryAnalyzer::getQueryPlan() @ 0x000000001497476d 16. /build/src/Interpreters/executeQuery.cpp:1405: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88806 17. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 18. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 19. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 20. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 21. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 22. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 23. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 24. ? @ 0x00007fbc6213eac3 25. ? @ 0x00007fbc621d0850 2025.07.28 12:00:28.750310 [ 3966 ] {} test_13.rmt2 (7f9b740d-015c-470e-8cc6-8ba33be0dc63): auto DB::StorageReplicatedMergeTree::processQueueEntry(ReplicatedMergeTreeQueue::SelectedEntryPtr)::(anonymous class)::operator()(LogEntryPtr &) const: Code: 86. DB::HTTPException: Received error from remote server http://146b4357c08d:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Ftest%2F01165%2Ftest_13%2Frmt%2Freplicas%2F1&part=20250728_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.6.10636.altinitytest (altinity build)) '. (RECEIVED_ERROR_FROM_REMOTE_IO_SERVER), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.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 const&, int&&, String const&, unsigned long&&, String const&) @ 0x000000000feda8d9 4. /build/src/IO/HTTPCommon.cpp:104: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x000000000feda6e2 5. /build/src/IO/HTTPCommon.cpp:93: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x000000000feda537 6. /build/src/IO/ReadWriteBufferFromHTTP.cpp:277: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x000000001184a4c4 7. /build/src/IO/ReadWriteBufferFromHTTP.cpp:285: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x000000001184a615 8. /build/src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x000000001184ae59 9. /build/src/IO/ReadWriteBufferFromHTTP.cpp:472: void std::__function::__policy_invoker::__call_impl[abi:se190107]>(std::__function::__policy_storage const*) @ 0x000000001184cedd 10. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001184858b 11. /build/src/IO/ReadWriteBufferFromHTTP.cpp:465: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x000000001184bf0b 12. /build/src/IO/ReadBuffer.h:60: DB::ReadBuffer::next() @ 0x000000000a148c7b 13. /build/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) @ 0x0000000011849fb2 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]>&)>&, 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&) @ 0x0000000011841980 15. /build/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) @ 0x000000001621208e 16. /build/src/Storages/StorageReplicatedMergeTree.cpp:5228: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl[abi:se190107] const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000015f9a5fe 17. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000015ed8bfd 18. /build/src/Storages/StorageReplicatedMergeTree.cpp:2514: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x0000000015ec9aab 19. /build/src/Storages/StorageReplicatedMergeTree.cpp:2349: DB::StorageReplicatedMergeTree::executeLogEntry(DB::ReplicatedMergeTreeLogEntry&) @ 0x0000000015eba91b 20. /build/src/Storages/StorageReplicatedMergeTree.cpp:3876: bool std::__function::__policy_invoker&)>::__call_impl[abi:se190107])::$_1, bool (std::shared_ptr&)>>(std::__function::__policy_storage const*, std::shared_ptr&) @ 0x0000000015f9837e 21. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000165d6fc3 22. /build/src/Storages/StorageReplicatedMergeTree.cpp:3872: DB::StorageReplicatedMergeTree::processQueueEntry(std::shared_ptr) @ 0x0000000015efc18a 23. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001624c1b2 24. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000162f9c70 25. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x00000000162fa55a 26. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc6653 27. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000000fccc4c3 28. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc3d92 29. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fcca080 30. ? @ 0x00007fbc6213eac3 31. ? @ 0x00007fbc621d0850 (version 25.3.6.10636.altinitytest (altinity build)) 2025.07.28 12:00:29.183644 [ 17371 ] {c5377177-6084-4e15-8df6-3691b6047fda} executeQuery: Code: 471. DB::Exception: Invalid value '0' for max_read_buffer_size. (INVALID_SETTING_VALUE) (version 25.3.6.10636.altinitytest (altinity build)) (from [::1]:59890) (comment: 02052_last_granula_adjust_logical_error.gen.sql) (query 19, line 59) (in query: select * apply max from data_02052_10_wide100000000 settings max_read_buffer_size=0, max_threads=1;), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type>, unsigned long const&) @ 0x000000000a951dcb 4. /build/src/Interpreters/Context.cpp:6171: DB::Context::getReadSettings() const @ 0x0000000014450b39 5. /build/src/Processors/QueryPlan/ReadFromMergeTree.cpp:211: DB::getMergeTreeReaderSettings(std::shared_ptr const&, DB::SelectQueryInfo const&) @ 0x0000000016e1d3ba 6. /build/src/Processors/QueryPlan/ReadFromMergeTree.cpp:351: 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) @ 0x0000000016e1c90b 7. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107], 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&) @ 0x0000000016401cd2 8. /build/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 @ 0x00000000163ec114 9. /build/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 @ 0x00000000163ebef8 10. /build/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) @ 0x0000000016635568 11. /build/src/Planner/PlannerJoinTree.cpp:946: DB::(anonymous namespace)::buildQueryPlanForTableExpression(std::shared_ptr, std::shared_ptr const&, DB::SelectQueryInfo const&, DB::SelectQueryOptions const&, std::shared_ptr&, bool, bool) @ 0x00000000149970ee 12. /build/src/Planner/PlannerJoinTree.cpp:2252: DB::buildJoinTreeQueryPlan(std::shared_ptr const&, DB::SelectQueryInfo const&, DB::SelectQueryOptions&, std::unordered_set, std::equal_to, std::allocator> const&, std::shared_ptr&) @ 0x000000001498e109 13. /build/src/Planner/Planner.cpp:1553: DB::Planner::buildPlanForQueryNode() @ 0x0000000014979dae 14. /build/src/Planner/Planner.cpp:1308: DB::Planner::buildQueryPlanIfNeeded() @ 0x000000001497685c 15. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:255: DB::InterpreterSelectQueryAnalyzer::getQueryPlan() @ 0x000000001497476d 16. /build/src/Interpreters/executeQuery.cpp:1405: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88806 17. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 18. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 19. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 20. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 21. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 22. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 23. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 24. ? @ 0x00007fbc6213eac3 25. ? @ 0x00007fbc621d0850 2025.07.28 12:00:29.189180 [ 17371 ] {} 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. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type>, unsigned long const&) @ 0x000000000a951dcb 4. /build/src/Interpreters/Context.cpp:6171: DB::Context::getReadSettings() const @ 0x0000000014450b39 5. /build/src/Processors/QueryPlan/ReadFromMergeTree.cpp:211: DB::getMergeTreeReaderSettings(std::shared_ptr const&, DB::SelectQueryInfo const&) @ 0x0000000016e1d3ba 6. /build/src/Processors/QueryPlan/ReadFromMergeTree.cpp:351: 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) @ 0x0000000016e1c90b 7. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107], 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&) @ 0x0000000016401cd2 8. /build/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 @ 0x00000000163ec114 9. /build/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 @ 0x00000000163ebef8 10. /build/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) @ 0x0000000016635568 11. /build/src/Planner/PlannerJoinTree.cpp:946: DB::(anonymous namespace)::buildQueryPlanForTableExpression(std::shared_ptr, std::shared_ptr const&, DB::SelectQueryInfo const&, DB::SelectQueryOptions const&, std::shared_ptr&, bool, bool) @ 0x00000000149970ee 12. /build/src/Planner/PlannerJoinTree.cpp:2252: DB::buildJoinTreeQueryPlan(std::shared_ptr const&, DB::SelectQueryInfo const&, DB::SelectQueryOptions&, std::unordered_set, std::equal_to, std::allocator> const&, std::shared_ptr&) @ 0x000000001498e109 13. /build/src/Planner/Planner.cpp:1553: DB::Planner::buildPlanForQueryNode() @ 0x0000000014979dae 14. /build/src/Planner/Planner.cpp:1308: DB::Planner::buildQueryPlanIfNeeded() @ 0x000000001497685c 15. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:255: DB::InterpreterSelectQueryAnalyzer::getQueryPlan() @ 0x000000001497476d 16. /build/src/Interpreters/executeQuery.cpp:1405: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88806 17. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 18. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 19. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 20. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 21. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 22. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 23. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 24. ? @ 0x00007fbc6213eac3 25. ? @ 0x00007fbc621d0850 2025.07.28 12:00:29.947014 [ 3962 ] {} test_13.rmt2 (7f9b740d-015c-470e-8cc6-8ba33be0dc63): auto DB::StorageReplicatedMergeTree::processQueueEntry(ReplicatedMergeTreeQueue::SelectedEntryPtr)::(anonymous class)::operator()(LogEntryPtr &) const: Code: 86. DB::HTTPException: Received error from remote server http://146b4357c08d:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Ftest%2F01165%2Ftest_13%2Frmt%2Freplicas%2F1&part=20250728_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.6.10636.altinitytest (altinity build)) '. (RECEIVED_ERROR_FROM_REMOTE_IO_SERVER), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.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 const&, int&&, String const&, unsigned long&&, String const&) @ 0x000000000feda8d9 4. /build/src/IO/HTTPCommon.cpp:104: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x000000000feda6e2 5. /build/src/IO/HTTPCommon.cpp:93: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x000000000feda537 6. /build/src/IO/ReadWriteBufferFromHTTP.cpp:277: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x000000001184a4c4 7. /build/src/IO/ReadWriteBufferFromHTTP.cpp:285: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x000000001184a615 8. /build/src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x000000001184ae59 9. /build/src/IO/ReadWriteBufferFromHTTP.cpp:472: void std::__function::__policy_invoker::__call_impl[abi:se190107]>(std::__function::__policy_storage const*) @ 0x000000001184cedd 10. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001184858b 11. /build/src/IO/ReadWriteBufferFromHTTP.cpp:465: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x000000001184bf0b 12. /build/src/IO/ReadBuffer.h:60: DB::ReadBuffer::next() @ 0x000000000a148c7b 13. /build/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) @ 0x0000000011849fb2 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]>&)>&, 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&) @ 0x0000000011841980 15. /build/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) @ 0x000000001621208e 16. /build/src/Storages/StorageReplicatedMergeTree.cpp:5228: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl[abi:se190107] const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000015f9a5fe 17. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000015ed8bfd 18. /build/src/Storages/StorageReplicatedMergeTree.cpp:2514: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x0000000015ec9aab 19. /build/src/Storages/StorageReplicatedMergeTree.cpp:2349: DB::StorageReplicatedMergeTree::executeLogEntry(DB::ReplicatedMergeTreeLogEntry&) @ 0x0000000015eba91b 20. /build/src/Storages/StorageReplicatedMergeTree.cpp:3876: bool std::__function::__policy_invoker&)>::__call_impl[abi:se190107])::$_1, bool (std::shared_ptr&)>>(std::__function::__policy_storage const*, std::shared_ptr&) @ 0x0000000015f9837e 21. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000165d6fc3 22. /build/src/Storages/StorageReplicatedMergeTree.cpp:3872: DB::StorageReplicatedMergeTree::processQueueEntry(std::shared_ptr) @ 0x0000000015efc18a 23. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001624c1b2 24. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000162f9c70 25. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x00000000162fa55a 26. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc6653 27. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000000fccc4c3 28. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc3d92 29. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fcca080 30. ? @ 0x00007fbc6213eac3 31. ? @ 0x00007fbc621d0850 (version 25.3.6.10636.altinitytest (altinity build)) 2025.07.28 12:00:30.116968 [ 17371 ] {dbb58d53-4013-4ffe-a677-684378efcd06} executeQuery: Code: 471. DB::Exception: Invalid value '0' for max_read_buffer_size. (INVALID_SETTING_VALUE) (version 25.3.6.10636.altinitytest (altinity build)) (from [::1]:59890) (comment: 02052_last_granula_adjust_logical_error.gen.sql) (query 24, line 75) (in query: select * apply max from data_02052_100_wide0 settings max_read_buffer_size=0, max_threads=1;), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type>, unsigned long const&) @ 0x000000000a951dcb 4. /build/src/Interpreters/Context.cpp:6171: DB::Context::getReadSettings() const @ 0x0000000014450b39 5. /build/src/Processors/QueryPlan/ReadFromMergeTree.cpp:211: DB::getMergeTreeReaderSettings(std::shared_ptr const&, DB::SelectQueryInfo const&) @ 0x0000000016e1d3ba 6. /build/src/Processors/QueryPlan/ReadFromMergeTree.cpp:351: 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) @ 0x0000000016e1c90b 7. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107], 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&) @ 0x0000000016401cd2 8. /build/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 @ 0x00000000163ec114 9. /build/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 @ 0x00000000163ebef8 10. /build/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) @ 0x0000000016635568 11. /build/src/Planner/PlannerJoinTree.cpp:946: DB::(anonymous namespace)::buildQueryPlanForTableExpression(std::shared_ptr, std::shared_ptr const&, DB::SelectQueryInfo const&, DB::SelectQueryOptions const&, std::shared_ptr&, bool, bool) @ 0x00000000149970ee 12. /build/src/Planner/PlannerJoinTree.cpp:2252: DB::buildJoinTreeQueryPlan(std::shared_ptr const&, DB::SelectQueryInfo const&, DB::SelectQueryOptions&, std::unordered_set, std::equal_to, std::allocator> const&, std::shared_ptr&) @ 0x000000001498e109 13. /build/src/Planner/Planner.cpp:1553: DB::Planner::buildPlanForQueryNode() @ 0x0000000014979dae 14. /build/src/Planner/Planner.cpp:1308: DB::Planner::buildQueryPlanIfNeeded() @ 0x000000001497685c 15. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:255: DB::InterpreterSelectQueryAnalyzer::getQueryPlan() @ 0x000000001497476d 16. /build/src/Interpreters/executeQuery.cpp:1405: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88806 17. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 18. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 19. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 20. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 21. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 22. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 23. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 24. ? @ 0x00007fbc6213eac3 25. ? @ 0x00007fbc621d0850 2025.07.28 12:00:30.144478 [ 17371 ] {} 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. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type>, unsigned long const&) @ 0x000000000a951dcb 4. /build/src/Interpreters/Context.cpp:6171: DB::Context::getReadSettings() const @ 0x0000000014450b39 5. /build/src/Processors/QueryPlan/ReadFromMergeTree.cpp:211: DB::getMergeTreeReaderSettings(std::shared_ptr const&, DB::SelectQueryInfo const&) @ 0x0000000016e1d3ba 6. /build/src/Processors/QueryPlan/ReadFromMergeTree.cpp:351: 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) @ 0x0000000016e1c90b 7. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107], 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&) @ 0x0000000016401cd2 8. /build/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 @ 0x00000000163ec114 9. /build/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 @ 0x00000000163ebef8 10. /build/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) @ 0x0000000016635568 11. /build/src/Planner/PlannerJoinTree.cpp:946: DB::(anonymous namespace)::buildQueryPlanForTableExpression(std::shared_ptr, std::shared_ptr const&, DB::SelectQueryInfo const&, DB::SelectQueryOptions const&, std::shared_ptr&, bool, bool) @ 0x00000000149970ee 12. /build/src/Planner/PlannerJoinTree.cpp:2252: DB::buildJoinTreeQueryPlan(std::shared_ptr const&, DB::SelectQueryInfo const&, DB::SelectQueryOptions&, std::unordered_set, std::equal_to, std::allocator> const&, std::shared_ptr&) @ 0x000000001498e109 13. /build/src/Planner/Planner.cpp:1553: DB::Planner::buildPlanForQueryNode() @ 0x0000000014979dae 14. /build/src/Planner/Planner.cpp:1308: DB::Planner::buildQueryPlanIfNeeded() @ 0x000000001497685c 15. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:255: DB::InterpreterSelectQueryAnalyzer::getQueryPlan() @ 0x000000001497476d 16. /build/src/Interpreters/executeQuery.cpp:1405: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88806 17. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 18. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 19. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 20. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 21. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 22. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 23. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 24. ? @ 0x00007fbc6213eac3 25. ? @ 0x00007fbc621d0850 2025.07.28 12:00:30.772147 [ 3977 ] {} test_13.rmt2 (7f9b740d-015c-470e-8cc6-8ba33be0dc63): auto DB::StorageReplicatedMergeTree::processQueueEntry(ReplicatedMergeTreeQueue::SelectedEntryPtr)::(anonymous class)::operator()(LogEntryPtr &) const: Code: 86. DB::HTTPException: Received error from remote server http://146b4357c08d:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Ftest%2F01165%2Ftest_13%2Frmt%2Freplicas%2F1&part=20250728_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.6.10636.altinitytest (altinity build)) '. (RECEIVED_ERROR_FROM_REMOTE_IO_SERVER), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.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 const&, int&&, String const&, unsigned long&&, String const&) @ 0x000000000feda8d9 4. /build/src/IO/HTTPCommon.cpp:104: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x000000000feda6e2 5. /build/src/IO/HTTPCommon.cpp:93: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x000000000feda537 6. /build/src/IO/ReadWriteBufferFromHTTP.cpp:277: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x000000001184a4c4 7. /build/src/IO/ReadWriteBufferFromHTTP.cpp:285: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x000000001184a615 8. /build/src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x000000001184ae59 9. /build/src/IO/ReadWriteBufferFromHTTP.cpp:472: void std::__function::__policy_invoker::__call_impl[abi:se190107]>(std::__function::__policy_storage const*) @ 0x000000001184cedd 10. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001184858b 11. /build/src/IO/ReadWriteBufferFromHTTP.cpp:465: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x000000001184bf0b 12. /build/src/IO/ReadBuffer.h:60: DB::ReadBuffer::next() @ 0x000000000a148c7b 13. /build/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) @ 0x0000000011849fb2 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]>&)>&, 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&) @ 0x0000000011841980 15. /build/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) @ 0x000000001621208e 16. /build/src/Storages/StorageReplicatedMergeTree.cpp:5228: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl[abi:se190107] const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000015f9a5fe 17. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000015ed8bfd 18. /build/src/Storages/StorageReplicatedMergeTree.cpp:2514: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x0000000015ec9aab 19. /build/src/Storages/StorageReplicatedMergeTree.cpp:2349: DB::StorageReplicatedMergeTree::executeLogEntry(DB::ReplicatedMergeTreeLogEntry&) @ 0x0000000015eba91b 20. /build/src/Storages/StorageReplicatedMergeTree.cpp:3876: bool std::__function::__policy_invoker&)>::__call_impl[abi:se190107])::$_1, bool (std::shared_ptr&)>>(std::__function::__policy_storage const*, std::shared_ptr&) @ 0x0000000015f9837e 21. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000165d6fc3 22. /build/src/Storages/StorageReplicatedMergeTree.cpp:3872: DB::StorageReplicatedMergeTree::processQueueEntry(std::shared_ptr) @ 0x0000000015efc18a 23. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001624c1b2 24. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000162f9c70 25. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x00000000162fa55a 26. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc6653 27. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000000fccc4c3 28. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc3d92 29. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fcca080 30. ? @ 0x00007fbc6213eac3 31. ? @ 0x00007fbc621d0850 (version 25.3.6.10636.altinitytest (altinity build)) 2025.07.28 12:00:30.874459 [ 17371 ] {d3132a8a-c6b1-430b-8657-5cfc303455c0} executeQuery: Code: 471. DB::Exception: Invalid value '0' for max_read_buffer_size. (INVALID_SETTING_VALUE) (version 25.3.6.10636.altinitytest (altinity build)) (from [::1]:59890) (comment: 02052_last_granula_adjust_logical_error.gen.sql) (query 29, line 89) (in query: select * apply max from data_02052_100_wide100000000 settings max_read_buffer_size=0, max_threads=1;), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type>, unsigned long const&) @ 0x000000000a951dcb 4. /build/src/Interpreters/Context.cpp:6171: DB::Context::getReadSettings() const @ 0x0000000014450b39 5. /build/src/Processors/QueryPlan/ReadFromMergeTree.cpp:211: DB::getMergeTreeReaderSettings(std::shared_ptr const&, DB::SelectQueryInfo const&) @ 0x0000000016e1d3ba 6. /build/src/Processors/QueryPlan/ReadFromMergeTree.cpp:351: 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) @ 0x0000000016e1c90b 7. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107], 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&) @ 0x0000000016401cd2 8. /build/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 @ 0x00000000163ec114 9. /build/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 @ 0x00000000163ebef8 10. /build/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) @ 0x0000000016635568 11. /build/src/Planner/PlannerJoinTree.cpp:946: DB::(anonymous namespace)::buildQueryPlanForTableExpression(std::shared_ptr, std::shared_ptr const&, DB::SelectQueryInfo const&, DB::SelectQueryOptions const&, std::shared_ptr&, bool, bool) @ 0x00000000149970ee 12. /build/src/Planner/PlannerJoinTree.cpp:2252: DB::buildJoinTreeQueryPlan(std::shared_ptr const&, DB::SelectQueryInfo const&, DB::SelectQueryOptions&, std::unordered_set, std::equal_to, std::allocator> const&, std::shared_ptr&) @ 0x000000001498e109 13. /build/src/Planner/Planner.cpp:1553: DB::Planner::buildPlanForQueryNode() @ 0x0000000014979dae 14. /build/src/Planner/Planner.cpp:1308: DB::Planner::buildQueryPlanIfNeeded() @ 0x000000001497685c 15. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:255: DB::InterpreterSelectQueryAnalyzer::getQueryPlan() @ 0x000000001497476d 16. /build/src/Interpreters/executeQuery.cpp:1405: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88806 17. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 18. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 19. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 20. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 21. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 22. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 23. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 24. ? @ 0x00007fbc6213eac3 25. ? @ 0x00007fbc621d0850 2025.07.28 12:00:30.902246 [ 17371 ] {} 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. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type>, unsigned long const&) @ 0x000000000a951dcb 4. /build/src/Interpreters/Context.cpp:6171: DB::Context::getReadSettings() const @ 0x0000000014450b39 5. /build/src/Processors/QueryPlan/ReadFromMergeTree.cpp:211: DB::getMergeTreeReaderSettings(std::shared_ptr const&, DB::SelectQueryInfo const&) @ 0x0000000016e1d3ba 6. /build/src/Processors/QueryPlan/ReadFromMergeTree.cpp:351: 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) @ 0x0000000016e1c90b 7. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107], 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&) @ 0x0000000016401cd2 8. /build/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 @ 0x00000000163ec114 9. /build/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 @ 0x00000000163ebef8 10. /build/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) @ 0x0000000016635568 11. /build/src/Planner/PlannerJoinTree.cpp:946: DB::(anonymous namespace)::buildQueryPlanForTableExpression(std::shared_ptr, std::shared_ptr const&, DB::SelectQueryInfo const&, DB::SelectQueryOptions const&, std::shared_ptr&, bool, bool) @ 0x00000000149970ee 12. /build/src/Planner/PlannerJoinTree.cpp:2252: DB::buildJoinTreeQueryPlan(std::shared_ptr const&, DB::SelectQueryInfo const&, DB::SelectQueryOptions&, std::unordered_set, std::equal_to, std::allocator> const&, std::shared_ptr&) @ 0x000000001498e109 13. /build/src/Planner/Planner.cpp:1553: DB::Planner::buildPlanForQueryNode() @ 0x0000000014979dae 14. /build/src/Planner/Planner.cpp:1308: DB::Planner::buildQueryPlanIfNeeded() @ 0x000000001497685c 15. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:255: DB::InterpreterSelectQueryAnalyzer::getQueryPlan() @ 0x000000001497476d 16. /build/src/Interpreters/executeQuery.cpp:1405: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88806 17. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 18. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 19. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 20. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 21. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 22. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 23. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 24. ? @ 0x00007fbc6213eac3 25. ? @ 0x00007fbc621d0850 2025.07.28 12:00:31.669059 [ 17371 ] {418a41d7-f49d-4d1e-8af0-1809e01fc0b1} executeQuery: Code: 471. DB::Exception: Invalid value '0' for max_read_buffer_size. (INVALID_SETTING_VALUE) (version 25.3.6.10636.altinitytest (altinity build)) (from [::1]:59890) (comment: 02052_last_granula_adjust_logical_error.gen.sql) (query 34, line 105) (in query: select * apply max from data_02052_10000_wide0 settings max_read_buffer_size=0, max_threads=1;), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type>, unsigned long const&) @ 0x000000000a951dcb 4. /build/src/Interpreters/Context.cpp:6171: DB::Context::getReadSettings() const @ 0x0000000014450b39 5. /build/src/Processors/QueryPlan/ReadFromMergeTree.cpp:211: DB::getMergeTreeReaderSettings(std::shared_ptr const&, DB::SelectQueryInfo const&) @ 0x0000000016e1d3ba 6. /build/src/Processors/QueryPlan/ReadFromMergeTree.cpp:351: 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) @ 0x0000000016e1c90b 7. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107], 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&) @ 0x0000000016401cd2 8. /build/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 @ 0x00000000163ec114 9. /build/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 @ 0x00000000163ebef8 10. /build/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) @ 0x0000000016635568 11. /build/src/Planner/PlannerJoinTree.cpp:946: DB::(anonymous namespace)::buildQueryPlanForTableExpression(std::shared_ptr, std::shared_ptr const&, DB::SelectQueryInfo const&, DB::SelectQueryOptions const&, std::shared_ptr&, bool, bool) @ 0x00000000149970ee 12. /build/src/Planner/PlannerJoinTree.cpp:2252: DB::buildJoinTreeQueryPlan(std::shared_ptr const&, DB::SelectQueryInfo const&, DB::SelectQueryOptions&, std::unordered_set, std::equal_to, std::allocator> const&, std::shared_ptr&) @ 0x000000001498e109 13. /build/src/Planner/Planner.cpp:1553: DB::Planner::buildPlanForQueryNode() @ 0x0000000014979dae 14. /build/src/Planner/Planner.cpp:1308: DB::Planner::buildQueryPlanIfNeeded() @ 0x000000001497685c 15. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:255: DB::InterpreterSelectQueryAnalyzer::getQueryPlan() @ 0x000000001497476d 16. /build/src/Interpreters/executeQuery.cpp:1405: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88806 17. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 18. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 19. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 20. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 21. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 22. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 23. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 24. ? @ 0x00007fbc6213eac3 25. ? @ 0x00007fbc621d0850 2025.07.28 12:00:31.682143 [ 17371 ] {} 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. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type>, unsigned long const&) @ 0x000000000a951dcb 4. /build/src/Interpreters/Context.cpp:6171: DB::Context::getReadSettings() const @ 0x0000000014450b39 5. /build/src/Processors/QueryPlan/ReadFromMergeTree.cpp:211: DB::getMergeTreeReaderSettings(std::shared_ptr const&, DB::SelectQueryInfo const&) @ 0x0000000016e1d3ba 6. /build/src/Processors/QueryPlan/ReadFromMergeTree.cpp:351: 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) @ 0x0000000016e1c90b 7. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107], 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&) @ 0x0000000016401cd2 8. /build/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 @ 0x00000000163ec114 9. /build/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 @ 0x00000000163ebef8 10. /build/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) @ 0x0000000016635568 11. /build/src/Planner/PlannerJoinTree.cpp:946: DB::(anonymous namespace)::buildQueryPlanForTableExpression(std::shared_ptr, std::shared_ptr const&, DB::SelectQueryInfo const&, DB::SelectQueryOptions const&, std::shared_ptr&, bool, bool) @ 0x00000000149970ee 12. /build/src/Planner/PlannerJoinTree.cpp:2252: DB::buildJoinTreeQueryPlan(std::shared_ptr const&, DB::SelectQueryInfo const&, DB::SelectQueryOptions&, std::unordered_set, std::equal_to, std::allocator> const&, std::shared_ptr&) @ 0x000000001498e109 13. /build/src/Planner/Planner.cpp:1553: DB::Planner::buildPlanForQueryNode() @ 0x0000000014979dae 14. /build/src/Planner/Planner.cpp:1308: DB::Planner::buildQueryPlanIfNeeded() @ 0x000000001497685c 15. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:255: DB::InterpreterSelectQueryAnalyzer::getQueryPlan() @ 0x000000001497476d 16. /build/src/Interpreters/executeQuery.cpp:1405: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88806 17. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 18. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 19. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 20. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 21. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 22. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 23. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 24. ? @ 0x00007fbc6213eac3 25. ? @ 0x00007fbc621d0850 2025.07.28 12:00:31.807239 [ 3969 ] {} test_13.rmt2 (7f9b740d-015c-470e-8cc6-8ba33be0dc63): auto DB::StorageReplicatedMergeTree::processQueueEntry(ReplicatedMergeTreeQueue::SelectedEntryPtr)::(anonymous class)::operator()(LogEntryPtr &) const: Code: 86. DB::HTTPException: Received error from remote server http://146b4357c08d:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Ftest%2F01165%2Ftest_13%2Frmt%2Freplicas%2F1&part=20250728_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.6.10636.altinitytest (altinity build)) '. (RECEIVED_ERROR_FROM_REMOTE_IO_SERVER), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.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 const&, int&&, String const&, unsigned long&&, String const&) @ 0x000000000feda8d9 4. /build/src/IO/HTTPCommon.cpp:104: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x000000000feda6e2 5. /build/src/IO/HTTPCommon.cpp:93: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x000000000feda537 6. /build/src/IO/ReadWriteBufferFromHTTP.cpp:277: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x000000001184a4c4 7. /build/src/IO/ReadWriteBufferFromHTTP.cpp:285: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x000000001184a615 8. /build/src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x000000001184ae59 9. /build/src/IO/ReadWriteBufferFromHTTP.cpp:472: void std::__function::__policy_invoker::__call_impl[abi:se190107]>(std::__function::__policy_storage const*) @ 0x000000001184cedd 10. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001184858b 11. /build/src/IO/ReadWriteBufferFromHTTP.cpp:465: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x000000001184bf0b 12. /build/src/IO/ReadBuffer.h:60: DB::ReadBuffer::next() @ 0x000000000a148c7b 13. /build/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) @ 0x0000000011849fb2 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]>&)>&, 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&) @ 0x0000000011841980 15. /build/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) @ 0x000000001621208e 16. /build/src/Storages/StorageReplicatedMergeTree.cpp:5228: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl[abi:se190107] const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000015f9a5fe 17. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000015ed8bfd 18. /build/src/Storages/StorageReplicatedMergeTree.cpp:2514: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x0000000015ec9aab 19. /build/src/Storages/StorageReplicatedMergeTree.cpp:2349: DB::StorageReplicatedMergeTree::executeLogEntry(DB::ReplicatedMergeTreeLogEntry&) @ 0x0000000015eba91b 20. /build/src/Storages/StorageReplicatedMergeTree.cpp:3876: bool std::__function::__policy_invoker&)>::__call_impl[abi:se190107])::$_1, bool (std::shared_ptr&)>>(std::__function::__policy_storage const*, std::shared_ptr&) @ 0x0000000015f9837e 21. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000165d6fc3 22. /build/src/Storages/StorageReplicatedMergeTree.cpp:3872: DB::StorageReplicatedMergeTree::processQueueEntry(std::shared_ptr) @ 0x0000000015efc18a 23. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001624c1b2 24. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000162f9c70 25. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x00000000162fa55a 26. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc6653 27. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000000fccc4c3 28. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc3d92 29. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fcca080 30. ? @ 0x00007fbc6213eac3 31. ? @ 0x00007fbc621d0850 (version 25.3.6.10636.altinitytest (altinity build)) 2025.07.28 12:00:32.354578 [ 3971 ] {} test_13.rmt2 (7f9b740d-015c-470e-8cc6-8ba33be0dc63): auto DB::StorageReplicatedMergeTree::processQueueEntry(ReplicatedMergeTreeQueue::SelectedEntryPtr)::(anonymous class)::operator()(LogEntryPtr &) const: Code: 86. DB::HTTPException: Received error from remote server http://146b4357c08d:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Ftest%2F01165%2Ftest_13%2Frmt%2Freplicas%2F1&part=20250728_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.6.10636.altinitytest (altinity build)) '. (RECEIVED_ERROR_FROM_REMOTE_IO_SERVER), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.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 const&, int&&, String const&, unsigned long&&, String const&) @ 0x000000000feda8d9 4. /build/src/IO/HTTPCommon.cpp:104: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x000000000feda6e2 5. /build/src/IO/HTTPCommon.cpp:93: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x000000000feda537 6. /build/src/IO/ReadWriteBufferFromHTTP.cpp:277: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x000000001184a4c4 7. /build/src/IO/ReadWriteBufferFromHTTP.cpp:285: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x000000001184a615 8. /build/src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x000000001184ae59 9. /build/src/IO/ReadWriteBufferFromHTTP.cpp:472: void std::__function::__policy_invoker::__call_impl[abi:se190107]>(std::__function::__policy_storage const*) @ 0x000000001184cedd 10. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001184858b 11. /build/src/IO/ReadWriteBufferFromHTTP.cpp:465: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x000000001184bf0b 12. /build/src/IO/ReadBuffer.h:60: DB::ReadBuffer::next() @ 0x000000000a148c7b 13. /build/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) @ 0x0000000011849fb2 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]>&)>&, 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&) @ 0x0000000011841980 15. /build/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) @ 0x000000001621208e 16. /build/src/Storages/StorageReplicatedMergeTree.cpp:5228: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl[abi:se190107] const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000015f9a5fe 17. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000015ed8bfd 18. /build/src/Storages/StorageReplicatedMergeTree.cpp:2514: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x0000000015ec9aab 19. /build/src/Storages/StorageReplicatedMergeTree.cpp:2349: DB::StorageReplicatedMergeTree::executeLogEntry(DB::ReplicatedMergeTreeLogEntry&) @ 0x0000000015eba91b 20. /build/src/Storages/StorageReplicatedMergeTree.cpp:3876: bool std::__function::__policy_invoker&)>::__call_impl[abi:se190107])::$_1, bool (std::shared_ptr&)>>(std::__function::__policy_storage const*, std::shared_ptr&) @ 0x0000000015f9837e 21. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000165d6fc3 22. /build/src/Storages/StorageReplicatedMergeTree.cpp:3872: DB::StorageReplicatedMergeTree::processQueueEntry(std::shared_ptr) @ 0x0000000015efc18a 23. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001624c1b2 24. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000162f9c70 25. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x00000000162fa55a 26. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc6653 27. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000000fccc4c3 28. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc3d92 29. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fcca080 30. ? @ 0x00007fbc6213eac3 31. ? @ 0x00007fbc621d0850 (version 25.3.6.10636.altinitytest (altinity build)) 2025.07.28 12:00:32.567128 [ 17371 ] {c2137e73-b13b-4ef4-8a73-962ebfd09ddb} executeQuery: Code: 471. DB::Exception: Invalid value '0' for max_read_buffer_size. (INVALID_SETTING_VALUE) (version 25.3.6.10636.altinitytest (altinity build)) (from [::1]:59890) (comment: 02052_last_granula_adjust_logical_error.gen.sql) (query 39, line 119) (in query: select * apply max from data_02052_10000_wide100000000 settings max_read_buffer_size=0, max_threads=1;), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type>, unsigned long const&) @ 0x000000000a951dcb 4. /build/src/Interpreters/Context.cpp:6171: DB::Context::getReadSettings() const @ 0x0000000014450b39 5. /build/src/Processors/QueryPlan/ReadFromMergeTree.cpp:211: DB::getMergeTreeReaderSettings(std::shared_ptr const&, DB::SelectQueryInfo const&) @ 0x0000000016e1d3ba 6. /build/src/Processors/QueryPlan/ReadFromMergeTree.cpp:351: 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) @ 0x0000000016e1c90b 7. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107], 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&) @ 0x0000000016401cd2 8. /build/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 @ 0x00000000163ec114 9. /build/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 @ 0x00000000163ebef8 10. /build/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) @ 0x0000000016635568 11. /build/src/Planner/PlannerJoinTree.cpp:946: DB::(anonymous namespace)::buildQueryPlanForTableExpression(std::shared_ptr, std::shared_ptr const&, DB::SelectQueryInfo const&, DB::SelectQueryOptions const&, std::shared_ptr&, bool, bool) @ 0x00000000149970ee 12. /build/src/Planner/PlannerJoinTree.cpp:2252: DB::buildJoinTreeQueryPlan(std::shared_ptr const&, DB::SelectQueryInfo const&, DB::SelectQueryOptions&, std::unordered_set, std::equal_to, std::allocator> const&, std::shared_ptr&) @ 0x000000001498e109 13. /build/src/Planner/Planner.cpp:1553: DB::Planner::buildPlanForQueryNode() @ 0x0000000014979dae 14. /build/src/Planner/Planner.cpp:1308: DB::Planner::buildQueryPlanIfNeeded() @ 0x000000001497685c 15. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:255: DB::InterpreterSelectQueryAnalyzer::getQueryPlan() @ 0x000000001497476d 16. /build/src/Interpreters/executeQuery.cpp:1405: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88806 17. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 18. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 19. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 20. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 21. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 22. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 23. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 24. ? @ 0x00007fbc6213eac3 25. ? @ 0x00007fbc621d0850 2025.07.28 12:00:32.577130 [ 17371 ] {} 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. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type>, unsigned long const&) @ 0x000000000a951dcb 4. /build/src/Interpreters/Context.cpp:6171: DB::Context::getReadSettings() const @ 0x0000000014450b39 5. /build/src/Processors/QueryPlan/ReadFromMergeTree.cpp:211: DB::getMergeTreeReaderSettings(std::shared_ptr const&, DB::SelectQueryInfo const&) @ 0x0000000016e1d3ba 6. /build/src/Processors/QueryPlan/ReadFromMergeTree.cpp:351: 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) @ 0x0000000016e1c90b 7. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107], 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&) @ 0x0000000016401cd2 8. /build/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 @ 0x00000000163ec114 9. /build/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 @ 0x00000000163ebef8 10. /build/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) @ 0x0000000016635568 11. /build/src/Planner/PlannerJoinTree.cpp:946: DB::(anonymous namespace)::buildQueryPlanForTableExpression(std::shared_ptr, std::shared_ptr const&, DB::SelectQueryInfo const&, DB::SelectQueryOptions const&, std::shared_ptr&, bool, bool) @ 0x00000000149970ee 12. /build/src/Planner/PlannerJoinTree.cpp:2252: DB::buildJoinTreeQueryPlan(std::shared_ptr const&, DB::SelectQueryInfo const&, DB::SelectQueryOptions&, std::unordered_set, std::equal_to, std::allocator> const&, std::shared_ptr&) @ 0x000000001498e109 13. /build/src/Planner/Planner.cpp:1553: DB::Planner::buildPlanForQueryNode() @ 0x0000000014979dae 14. /build/src/Planner/Planner.cpp:1308: DB::Planner::buildQueryPlanIfNeeded() @ 0x000000001497685c 15. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:255: DB::InterpreterSelectQueryAnalyzer::getQueryPlan() @ 0x000000001497476d 16. /build/src/Interpreters/executeQuery.cpp:1405: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88806 17. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 18. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 19. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 20. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 21. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 22. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 23. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 24. ? @ 0x00007fbc6213eac3 25. ? @ 0x00007fbc621d0850 2025.07.28 12:00:33.197770 [ 3968 ] {} test_13.rmt2 (7f9b740d-015c-470e-8cc6-8ba33be0dc63): auto DB::StorageReplicatedMergeTree::processQueueEntry(ReplicatedMergeTreeQueue::SelectedEntryPtr)::(anonymous class)::operator()(LogEntryPtr &) const: Code: 86. DB::HTTPException: Received error from remote server http://146b4357c08d:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Ftest%2F01165%2Ftest_13%2Frmt%2Freplicas%2F1&part=20250728_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.6.10636.altinitytest (altinity build)) '. (RECEIVED_ERROR_FROM_REMOTE_IO_SERVER), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.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 const&, int&&, String const&, unsigned long&&, String const&) @ 0x000000000feda8d9 4. /build/src/IO/HTTPCommon.cpp:104: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x000000000feda6e2 5. /build/src/IO/HTTPCommon.cpp:93: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x000000000feda537 6. /build/src/IO/ReadWriteBufferFromHTTP.cpp:277: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x000000001184a4c4 7. /build/src/IO/ReadWriteBufferFromHTTP.cpp:285: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x000000001184a615 8. /build/src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x000000001184ae59 9. /build/src/IO/ReadWriteBufferFromHTTP.cpp:472: void std::__function::__policy_invoker::__call_impl[abi:se190107]>(std::__function::__policy_storage const*) @ 0x000000001184cedd 10. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001184858b 11. /build/src/IO/ReadWriteBufferFromHTTP.cpp:465: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x000000001184bf0b 12. /build/src/IO/ReadBuffer.h:60: DB::ReadBuffer::next() @ 0x000000000a148c7b 13. /build/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) @ 0x0000000011849fb2 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]>&)>&, 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&) @ 0x0000000011841980 15. /build/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) @ 0x000000001621208e 16. /build/src/Storages/StorageReplicatedMergeTree.cpp:5228: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl[abi:se190107] const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000015f9a5fe 17. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000015ed8bfd 18. /build/src/Storages/StorageReplicatedMergeTree.cpp:2514: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x0000000015ec9aab 19. /build/src/Storages/StorageReplicatedMergeTree.cpp:2349: DB::StorageReplicatedMergeTree::executeLogEntry(DB::ReplicatedMergeTreeLogEntry&) @ 0x0000000015eba91b 20. /build/src/Storages/StorageReplicatedMergeTree.cpp:3876: bool std::__function::__policy_invoker&)>::__call_impl[abi:se190107])::$_1, bool (std::shared_ptr&)>>(std::__function::__policy_storage const*, std::shared_ptr&) @ 0x0000000015f9837e 21. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000165d6fc3 22. /build/src/Storages/StorageReplicatedMergeTree.cpp:3872: DB::StorageReplicatedMergeTree::processQueueEntry(std::shared_ptr) @ 0x0000000015efc18a 23. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001624c1b2 24. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000162f9c70 25. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x00000000162fa55a 26. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc6653 27. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000000fccc4c3 28. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc3d92 29. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fcca080 30. ? @ 0x00007fbc6213eac3 31. ? @ 0x00007fbc621d0850 (version 25.3.6.10636.altinitytest (altinity build)) 2025.07.28 12:00:33.585372 [ 17232 ] {} 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. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception>&, String>(int, FormatStringHelperImpl>&>::type, std::type_identity::type>, std::basic_string_view>&, String&&) @ 0x000000001385a5eb 4. /build/src/Access/SettingsConstraints.cpp:376: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000013859b18 5. /build/src/Access/SettingsConstraints.cpp:300: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000013858faf 6. /build/src/Access/SettingsConstraints.cpp:209: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000013859223 7. /build/src/Interpreters/Context.cpp:2690: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000014436134 8. /build/src/Interpreters/Context.cpp:2729: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x000000001443662b 9. /build/src/Server/HTTPHandler.cpp:457: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000001686d165 10. /build/src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x0000000016870807 11. /build/src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x0000000016907e99 12. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 13. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 14. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 15. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 16. ? @ 0x00007fbc6213eac3 17. ? @ 0x00007fbc621d0850 (version 25.3.6.10636.altinitytest (altinity build)) 2025.07.28 12:00:34.006131 [ 4900 ] {bff1919d-5244-4aa8-8761-cc474695905b} executeQuery: Code: 57. DB::Exception: Table test_5.test already exists. (TABLE_ALREADY_EXISTS) (version 25.3.6.10636.altinitytest (altinity build)) (from 0.0.0.0:0) (comment: 03293_forbid_cluster_table_engine.sql) (in query: /* ddl_entry=query-0000000137 */ CREATE TABLE test_5.test UUID '675c1312-6ce7-4365-a895-3317c3833a7f' (`a` Int32) AS s3Cluster('test_shard_localhost', 'http://localhost:11111/test/a.tsv', 'TSV', 'a Int32')), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000a06a8eb 4. /build/src/Interpreters/InterpreterCreateQuery.cpp:1824: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x0000000014901d53 5. /build/src/Interpreters/InterpreterCreateQuery.cpp:1743: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000148f9aa9 6. /build/src/Interpreters/InterpreterCreateQuery.cpp:2352: DB::InterpreterCreateQuery::execute() @ 0x0000000014905a41 7. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88dc9 8. /build/src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x0000000014c8ca7b 9. /build/src/Interpreters/DDLWorker.cpp:510: DB::DDLWorker::tryExecuteQuery(DB::DDLTaskBase&, std::shared_ptr const&, bool) @ 0x00000000144dab9e 10. /build/src/Interpreters/DDLWorker.cpp:675: DB::DDLWorker::processTask(DB::DDLTaskBase&, std::shared_ptr const&, bool) @ 0x00000000144d8ffe 11. /build/src/Databases/DatabaseReplicatedWorker.cpp:372: DB::DatabaseReplicatedDDLWorker::tryEnqueueAndExecuteEntry(DB::DDLLogEntry&, std::shared_ptr, bool) @ 0x0000000013dc29ab 12. /build/src/Databases/DatabaseReplicated.cpp:1139: DB::DatabaseReplicated::tryEnqueueReplicatedDDL(std::shared_ptr const&, std::shared_ptr, DB::QueryFlags) @ 0x0000000013d9f73c 13. /build/src/Interpreters/InterpreterCreateQuery.cpp:1723: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000148f96f8 14. /build/src/Interpreters/InterpreterCreateQuery.cpp:2352: DB::InterpreterCreateQuery::execute() @ 0x0000000014905a41 15. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88dc9 16. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 17. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 18. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 19. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 20. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 21. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 22. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 23. ? @ 0x00007fbc6213eac3 24. ? @ 0x00007fbc621d0850 2025.07.28 12:00:34.026270 [ 3961 ] {} test_13.rmt2 (7f9b740d-015c-470e-8cc6-8ba33be0dc63): auto DB::StorageReplicatedMergeTree::processQueueEntry(ReplicatedMergeTreeQueue::SelectedEntryPtr)::(anonymous class)::operator()(LogEntryPtr &) const: Code: 86. DB::HTTPException: Received error from remote server http://146b4357c08d:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Ftest%2F01165%2Ftest_13%2Frmt%2Freplicas%2F1&part=20250728_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.6.10636.altinitytest (altinity build)) '. (RECEIVED_ERROR_FROM_REMOTE_IO_SERVER), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.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 const&, int&&, String const&, unsigned long&&, String const&) @ 0x000000000feda8d9 4. /build/src/IO/HTTPCommon.cpp:104: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x000000000feda6e2 5. /build/src/IO/HTTPCommon.cpp:93: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x000000000feda537 6. /build/src/IO/ReadWriteBufferFromHTTP.cpp:277: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x000000001184a4c4 7. /build/src/IO/ReadWriteBufferFromHTTP.cpp:285: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x000000001184a615 8. /build/src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x000000001184ae59 9. /build/src/IO/ReadWriteBufferFromHTTP.cpp:472: void std::__function::__policy_invoker::__call_impl[abi:se190107]>(std::__function::__policy_storage const*) @ 0x000000001184cedd 10. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001184858b 11. /build/src/IO/ReadWriteBufferFromHTTP.cpp:465: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x000000001184bf0b 12. /build/src/IO/ReadBuffer.h:60: DB::ReadBuffer::next() @ 0x000000000a148c7b 13. /build/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) @ 0x0000000011849fb2 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]>&)>&, 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&) @ 0x0000000011841980 15. /build/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) @ 0x000000001621208e 16. /build/src/Storages/StorageReplicatedMergeTree.cpp:5228: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl[abi:se190107] const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000015f9a5fe 17. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000015ed8bfd 18. /build/src/Storages/StorageReplicatedMergeTree.cpp:2514: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x0000000015ec9aab 19. /build/src/Storages/StorageReplicatedMergeTree.cpp:2349: DB::StorageReplicatedMergeTree::executeLogEntry(DB::ReplicatedMergeTreeLogEntry&) @ 0x0000000015eba91b 20. /build/src/Storages/StorageReplicatedMergeTree.cpp:3876: bool std::__function::__policy_invoker&)>::__call_impl[abi:se190107])::$_1, bool (std::shared_ptr&)>>(std::__function::__policy_storage const*, std::shared_ptr&) @ 0x0000000015f9837e 21. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000165d6fc3 22. /build/src/Storages/StorageReplicatedMergeTree.cpp:3872: DB::StorageReplicatedMergeTree::processQueueEntry(std::shared_ptr) @ 0x0000000015efc18a 23. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001624c1b2 24. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000162f9c70 25. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x00000000162fa55a 26. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc6653 27. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000000fccc4c3 28. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc3d92 29. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fcca080 30. ? @ 0x00007fbc6213eac3 31. ? @ 0x00007fbc621d0850 (version 25.3.6.10636.altinitytest (altinity build)) 2025.07.28 12:00:34.028971 [ 4900 ] {bff1919d-5244-4aa8-8761-cc474695905b} executeQuery: Code: 57. DB::Exception: Table test_5.test already exists. (TABLE_ALREADY_EXISTS) (version 25.3.6.10636.altinitytest (altinity build)) (from [::1]:43236) (comment: 03293_forbid_cluster_table_engine.sql) (query 1, line 4) (in query: CREATE TABLE test AS s3Cluster('test_shard_localhost', 'http://localhost:11111/test/a.tsv', 'TSV', 'a Int32');), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000a06a8eb 4. /build/src/Interpreters/InterpreterCreateQuery.cpp:1824: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x0000000014901d53 5. /build/src/Interpreters/InterpreterCreateQuery.cpp:1743: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000148f9aa9 6. /build/src/Interpreters/InterpreterCreateQuery.cpp:2352: DB::InterpreterCreateQuery::execute() @ 0x0000000014905a41 7. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88dc9 8. /build/src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x0000000014c8ca7b 9. /build/src/Interpreters/DDLWorker.cpp:510: DB::DDLWorker::tryExecuteQuery(DB::DDLTaskBase&, std::shared_ptr const&, bool) @ 0x00000000144dab9e 10. /build/src/Interpreters/DDLWorker.cpp:675: DB::DDLWorker::processTask(DB::DDLTaskBase&, std::shared_ptr const&, bool) @ 0x00000000144d8ffe 11. /build/src/Databases/DatabaseReplicatedWorker.cpp:372: DB::DatabaseReplicatedDDLWorker::tryEnqueueAndExecuteEntry(DB::DDLLogEntry&, std::shared_ptr, bool) @ 0x0000000013dc29ab 12. /build/src/Databases/DatabaseReplicated.cpp:1139: DB::DatabaseReplicated::tryEnqueueReplicatedDDL(std::shared_ptr const&, std::shared_ptr, DB::QueryFlags) @ 0x0000000013d9f73c 13. /build/src/Interpreters/InterpreterCreateQuery.cpp:1723: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000148f96f8 14. /build/src/Interpreters/InterpreterCreateQuery.cpp:2352: DB::InterpreterCreateQuery::execute() @ 0x0000000014905a41 15. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88dc9 16. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 17. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 18. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 19. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 20. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 21. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 22. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 23. ? @ 0x00007fbc6213eac3 24. ? @ 0x00007fbc621d0850 2025.07.28 12:00:34.035976 [ 4900 ] {} TCPHandler: Code: 57. DB::Exception: Table test_5.test already exists. (TABLE_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000a06a8eb 4. /build/src/Interpreters/InterpreterCreateQuery.cpp:1824: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x0000000014901d53 5. /build/src/Interpreters/InterpreterCreateQuery.cpp:1743: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000148f9aa9 6. /build/src/Interpreters/InterpreterCreateQuery.cpp:2352: DB::InterpreterCreateQuery::execute() @ 0x0000000014905a41 7. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88dc9 8. /build/src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x0000000014c8ca7b 9. /build/src/Interpreters/DDLWorker.cpp:510: DB::DDLWorker::tryExecuteQuery(DB::DDLTaskBase&, std::shared_ptr const&, bool) @ 0x00000000144dab9e 10. /build/src/Interpreters/DDLWorker.cpp:675: DB::DDLWorker::processTask(DB::DDLTaskBase&, std::shared_ptr const&, bool) @ 0x00000000144d8ffe 11. /build/src/Databases/DatabaseReplicatedWorker.cpp:372: DB::DatabaseReplicatedDDLWorker::tryEnqueueAndExecuteEntry(DB::DDLLogEntry&, std::shared_ptr, bool) @ 0x0000000013dc29ab 12. /build/src/Databases/DatabaseReplicated.cpp:1139: DB::DatabaseReplicated::tryEnqueueReplicatedDDL(std::shared_ptr const&, std::shared_ptr, DB::QueryFlags) @ 0x0000000013d9f73c 13. /build/src/Interpreters/InterpreterCreateQuery.cpp:1723: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000148f96f8 14. /build/src/Interpreters/InterpreterCreateQuery.cpp:2352: DB::InterpreterCreateQuery::execute() @ 0x0000000014905a41 15. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88dc9 16. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 17. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 18. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 19. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 20. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 21. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 22. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 23. ? @ 0x00007fbc6213eac3 24. ? @ 0x00007fbc621d0850 2025.07.28 12:00:34.584025 [ 17371 ] {92949f93-72ad-4c8b-bc12-518e73bc7efb} executeQuery: Code: 582. DB::Exception: There is no projection pToDro in table. Maybe you meant: ['pToDrop']. (NO_SUCH_PROJECTION_IN_TABLE) (version 25.3.6.10636.altinitytest (altinity build)) (from [::1]:43294) (comment: 02250_hints_for_projections.sh) (query 1, line 1) (in query: ALTER TABLE t DROP PROJECTION pToDro), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x000000000a6a1e2b 4. /build/src/Storages/ProjectionsDescription.cpp:439: DB::ProjectionsDescription::remove(String const&, bool) @ 0x0000000015d4b6fc 5. /build/src/Storages/AlterCommands.cpp:860: DB::AlterCommand::apply(DB::StorageInMemoryMetadata&, std::shared_ptr) const @ 0x0000000015cebf5f 6. /build/src/Storages/AlterCommands.cpp:1263: DB::AlterCommands::apply(DB::StorageInMemoryMetadata&, std::shared_ptr) const @ 0x0000000015cf2c7b 7. /build/src/Storages/MergeTree/MergeTreeData.cpp:3534: DB::MergeTreeData::checkAlterIsPossible(DB::AlterCommands const&, std::shared_ptr) const @ 0x00000000163355eb 8. /build/src/Interpreters/InterpreterAlterQuery.cpp:215: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x00000000148deab3 9. /build/src/Interpreters/InterpreterAlterQuery.cpp:77: DB::InterpreterAlterQuery::execute() @ 0x00000000148dcb0d 10. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88dc9 11. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 12. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 13. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 14. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 15. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 16. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 17. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 18. ? @ 0x00007fbc6213eac3 19. ? @ 0x00007fbc621d0850 2025.07.28 12:00:34.685004 [ 17371 ] {} TCPHandler: Code: 582. DB::Exception: There is no projection pToDro in table. Maybe you meant: ['pToDrop']. (NO_SUCH_PROJECTION_IN_TABLE), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x000000000a6a1e2b 4. /build/src/Storages/ProjectionsDescription.cpp:439: DB::ProjectionsDescription::remove(String const&, bool) @ 0x0000000015d4b6fc 5. /build/src/Storages/AlterCommands.cpp:860: DB::AlterCommand::apply(DB::StorageInMemoryMetadata&, std::shared_ptr) const @ 0x0000000015cebf5f 6. /build/src/Storages/AlterCommands.cpp:1263: DB::AlterCommands::apply(DB::StorageInMemoryMetadata&, std::shared_ptr) const @ 0x0000000015cf2c7b 7. /build/src/Storages/MergeTree/MergeTreeData.cpp:3534: DB::MergeTreeData::checkAlterIsPossible(DB::AlterCommands const&, std::shared_ptr) const @ 0x00000000163355eb 8. /build/src/Interpreters/InterpreterAlterQuery.cpp:215: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x00000000148deab3 9. /build/src/Interpreters/InterpreterAlterQuery.cpp:77: DB::InterpreterAlterQuery::execute() @ 0x00000000148dcb0d 10. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88dc9 11. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 12. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 13. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 14. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 15. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 16. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 17. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 18. ? @ 0x00007fbc6213eac3 19. ? @ 0x00007fbc621d0850 2025.07.28 12:00:34.717707 [ 3960 ] {} test_13.rmt2 (7f9b740d-015c-470e-8cc6-8ba33be0dc63): auto DB::StorageReplicatedMergeTree::processQueueEntry(ReplicatedMergeTreeQueue::SelectedEntryPtr)::(anonymous class)::operator()(LogEntryPtr &) const: Code: 86. DB::HTTPException: Received error from remote server http://146b4357c08d:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Ftest%2F01165%2Ftest_13%2Frmt%2Freplicas%2F1&part=20250728_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.6.10636.altinitytest (altinity build)) '. (RECEIVED_ERROR_FROM_REMOTE_IO_SERVER), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.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 const&, int&&, String const&, unsigned long&&, String const&) @ 0x000000000feda8d9 4. /build/src/IO/HTTPCommon.cpp:104: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x000000000feda6e2 5. /build/src/IO/HTTPCommon.cpp:93: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x000000000feda537 6. /build/src/IO/ReadWriteBufferFromHTTP.cpp:277: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x000000001184a4c4 7. /build/src/IO/ReadWriteBufferFromHTTP.cpp:285: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x000000001184a615 8. /build/src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x000000001184ae59 9. /build/src/IO/ReadWriteBufferFromHTTP.cpp:472: void std::__function::__policy_invoker::__call_impl[abi:se190107]>(std::__function::__policy_storage const*) @ 0x000000001184cedd 10. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001184858b 11. /build/src/IO/ReadWriteBufferFromHTTP.cpp:465: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x000000001184bf0b 12. /build/src/IO/ReadBuffer.h:60: DB::ReadBuffer::next() @ 0x000000000a148c7b 13. /build/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) @ 0x0000000011849fb2 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]>&)>&, 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&) @ 0x0000000011841980 15. /build/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) @ 0x000000001621208e 16. /build/src/Storages/StorageReplicatedMergeTree.cpp:5228: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl[abi:se190107] const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000015f9a5fe 17. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000015ed8bfd 18. /build/src/Storages/StorageReplicatedMergeTree.cpp:2514: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x0000000015ec9aab 19. /build/src/Storages/StorageReplicatedMergeTree.cpp:2349: DB::StorageReplicatedMergeTree::executeLogEntry(DB::ReplicatedMergeTreeLogEntry&) @ 0x0000000015eba91b 20. /build/src/Storages/StorageReplicatedMergeTree.cpp:3876: bool std::__function::__policy_invoker&)>::__call_impl[abi:se190107])::$_1, bool (std::shared_ptr&)>>(std::__function::__policy_storage const*, std::shared_ptr&) @ 0x0000000015f9837e 21. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000165d6fc3 22. /build/src/Storages/StorageReplicatedMergeTree.cpp:3872: DB::StorageReplicatedMergeTree::processQueueEntry(std::shared_ptr) @ 0x0000000015efc18a 23. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001624c1b2 24. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000162f9c70 25. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x00000000162fa55a 26. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc6653 27. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000000fccc4c3 28. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc3d92 29. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fcca080 30. ? @ 0x00007fbc6213eac3 31. ? @ 0x00007fbc621d0850 (version 25.3.6.10636.altinitytest (altinity build)) 2025.07.28 12:00:35.399220 [ 3972 ] {} test_13.rmt2 (7f9b740d-015c-470e-8cc6-8ba33be0dc63): auto DB::StorageReplicatedMergeTree::processQueueEntry(ReplicatedMergeTreeQueue::SelectedEntryPtr)::(anonymous class)::operator()(LogEntryPtr &) const: Code: 86. DB::HTTPException: Received error from remote server http://146b4357c08d:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Ftest%2F01165%2Ftest_13%2Frmt%2Freplicas%2F1&part=20250728_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.6.10636.altinitytest (altinity build)) '. (RECEIVED_ERROR_FROM_REMOTE_IO_SERVER), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.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 const&, int&&, String const&, unsigned long&&, String const&) @ 0x000000000feda8d9 4. /build/src/IO/HTTPCommon.cpp:104: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x000000000feda6e2 5. /build/src/IO/HTTPCommon.cpp:93: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x000000000feda537 6. /build/src/IO/ReadWriteBufferFromHTTP.cpp:277: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x000000001184a4c4 7. /build/src/IO/ReadWriteBufferFromHTTP.cpp:285: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x000000001184a615 8. /build/src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x000000001184ae59 9. /build/src/IO/ReadWriteBufferFromHTTP.cpp:472: void std::__function::__policy_invoker::__call_impl[abi:se190107]>(std::__function::__policy_storage const*) @ 0x000000001184cedd 10. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001184858b 11. /build/src/IO/ReadWriteBufferFromHTTP.cpp:465: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x000000001184bf0b 12. /build/src/IO/ReadBuffer.h:60: DB::ReadBuffer::next() @ 0x000000000a148c7b 13. /build/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) @ 0x0000000011849fb2 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]>&)>&, 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&) @ 0x0000000011841980 15. /build/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) @ 0x000000001621208e 16. /build/src/Storages/StorageReplicatedMergeTree.cpp:5228: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl[abi:se190107] const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000015f9a5fe 17. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000015ed8bfd 18. /build/src/Storages/StorageReplicatedMergeTree.cpp:2514: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x0000000015ec9aab 19. /build/src/Storages/StorageReplicatedMergeTree.cpp:2349: DB::StorageReplicatedMergeTree::executeLogEntry(DB::ReplicatedMergeTreeLogEntry&) @ 0x0000000015eba91b 20. /build/src/Storages/StorageReplicatedMergeTree.cpp:3876: bool std::__function::__policy_invoker&)>::__call_impl[abi:se190107])::$_1, bool (std::shared_ptr&)>>(std::__function::__policy_storage const*, std::shared_ptr&) @ 0x0000000015f9837e 21. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000165d6fc3 22. /build/src/Storages/StorageReplicatedMergeTree.cpp:3872: DB::StorageReplicatedMergeTree::processQueueEntry(std::shared_ptr) @ 0x0000000015efc18a 23. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001624c1b2 24. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000162f9c70 25. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x00000000162fa55a 26. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc6653 27. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000000fccc4c3 28. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc3d92 29. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fcca080 30. ? @ 0x00007fbc6213eac3 31. ? @ 0x00007fbc621d0850 (version 25.3.6.10636.altinitytest (altinity build)) 2025.07.28 12:00:35.474031 [ 4900 ] {979c1242-159d-46b6-80fa-f6e3391db12b} executeQuery: Code: 36. DB::Exception: The size of bloom filter cannot be zero. (BAD_ARGUMENTS) (version 25.3.6.10636.altinitytest (altinity build)) (from 0.0.0.0:0) (comment: 01384_bloom_filter_bad_arguments.sql) (in query: /* ddl_entry=query-0000000139 */ CREATE TABLE test_5.test UUID '8886b619-c837-442c-89b7-6f7f1316b006' (`a` String, INDEX a a TYPE tokenbf_v1(0, 2, 0) GRANULARITY 1) ENGINE = MergeTree ORDER BY a SETTINGS index_granularity = 31235, 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 = 258222230, compact_parts_max_bytes_to_buffer = 472164226, compact_parts_max_granules_to_buffer = 119, compact_parts_merge_max_bytes_to_prefetch_part = 17681283, merge_max_block_size = 2282, old_parts_lifetime = 480., prefer_fetch_merged_part_size_threshold = 10737418240, vertical_merge_algorithm_min_rows_to_activate = 387269, vertical_merge_algorithm_min_columns_to_activate = 100, min_merge_bytes_to_use_direct_io = 10737418240, index_granularity_bytes = 16941609, use_const_adaptive_granularity = true, enable_index_granularity_compression = false, concurrent_part_removal_threshold = 91, 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 = 59202, primary_key_compress_block_size = 46175, 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. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000000a074fcb 4. /build/src/Interpreters/BloomFilter.cpp:28: DB::BloomFilterParameters::BloomFilterParameters(unsigned long, unsigned long, unsigned long) @ 0x00000000143f66cf 5. /build/src/Storages/MergeTree/MergeTreeIndexBloomFilterText.cpp:814: DB::bloomFilterIndexTextValidator(DB::IndexDescription const&, bool) @ 0x0000000016442fea 6. /build/src/Storages/MergeTree/MergeTreeData.cpp:807: DB::MergeTreeData::checkProperties(DB::StorageInMemoryMetadata const&, DB::StorageInMemoryMetadata const&, bool, bool, bool, bool, std::shared_ptr) const @ 0x0000000016307fa2 7. /build/src/Storages/MergeTree/MergeTreeData.cpp:868: DB::MergeTreeData::setProperties(DB::StorageInMemoryMetadata const&, DB::StorageInMemoryMetadata const&, bool, std::shared_ptr) @ 0x000000001630257f 8. /build/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) @ 0x00000000163014fc 9. /build/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>) @ 0x0000000016632995 10. /build/contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: std::shared_ptr std::allocate_shared[abi:se190107], 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>&&) @ 0x00000000166326f0 11. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:851: DB::create(DB::StorageFactory::Arguments const&) @ 0x000000001662f01d 12. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000015d81ea2 13. /build/src/Interpreters/InterpreterCreateQuery.cpp:1945: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x00000000149009bb 14. /build/src/Interpreters/InterpreterCreateQuery.cpp:1743: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000148f9aa9 15. /build/src/Interpreters/InterpreterCreateQuery.cpp:2352: DB::InterpreterCreateQuery::execute() @ 0x0000000014905a41 16. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88dc9 17. /build/src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x0000000014c8ca7b 18. /build/src/Interpreters/DDLWorker.cpp:510: DB::DDLWorker::tryExecuteQuery(DB::DDLTaskBase&, std::shared_ptr const&, bool) @ 0x00000000144dab9e 19. /build/src/Interpreters/DDLWorker.cpp:675: DB::DDLWorker::processTask(DB::DDLTaskBase&, std::shared_ptr const&, bool) @ 0x00000000144d8ffe 20. /build/src/Databases/DatabaseReplicatedWorker.cpp:372: DB::DatabaseReplicatedDDLWorker::tryEnqueueAndExecuteEntry(DB::DDLLogEntry&, std::shared_ptr, bool) @ 0x0000000013dc29ab 21. /build/src/Databases/DatabaseReplicated.cpp:1139: DB::DatabaseReplicated::tryEnqueueReplicatedDDL(std::shared_ptr const&, std::shared_ptr, DB::QueryFlags) @ 0x0000000013d9f73c 22. /build/src/Interpreters/InterpreterCreateQuery.cpp:1723: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000148f96f8 23. /build/src/Interpreters/InterpreterCreateQuery.cpp:2352: DB::InterpreterCreateQuery::execute() @ 0x0000000014905a41 24. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88dc9 25. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 26. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 27. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 28. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 29. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 30. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 31. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 2025.07.28 12:00:35.507948 [ 4900 ] {979c1242-159d-46b6-80fa-f6e3391db12b} executeQuery: Code: 36. DB::Exception: The size of bloom filter cannot be zero. (BAD_ARGUMENTS) (version 25.3.6.10636.altinitytest (altinity build)) (from [::1]:43270) (comment: 01384_bloom_filter_bad_arguments.sql) (query 2, line 3) (in query: CREATE TABLE test (`a` String, INDEX a a TYPE tokenbf_v1(0, 2, 0) GRANULARITY 1) ENGINE = MergeTree ORDER BY a SETTINGS index_granularity = 31235, 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 = 258222230, compact_parts_max_bytes_to_buffer = 472164226, compact_parts_max_granules_to_buffer = 119, compact_parts_merge_max_bytes_to_prefetch_part = 17681283, merge_max_block_size = 2282, old_parts_lifetime = 480., prefer_fetch_merged_part_size_threshold = 10737418240, vertical_merge_algorithm_min_rows_to_activate = 387269, vertical_merge_algorithm_min_columns_to_activate = 100, min_merge_bytes_to_use_direct_io = 10737418240, index_granularity_bytes = 16941609, use_const_adaptive_granularity = true, enable_index_granularity_compression = false, concurrent_part_removal_threshold = 91, 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 = 59202, primary_key_compress_block_size = 46175, 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. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000000a074fcb 4. /build/src/Interpreters/BloomFilter.cpp:28: DB::BloomFilterParameters::BloomFilterParameters(unsigned long, unsigned long, unsigned long) @ 0x00000000143f66cf 5. /build/src/Storages/MergeTree/MergeTreeIndexBloomFilterText.cpp:814: DB::bloomFilterIndexTextValidator(DB::IndexDescription const&, bool) @ 0x0000000016442fea 6. /build/src/Storages/MergeTree/MergeTreeData.cpp:807: DB::MergeTreeData::checkProperties(DB::StorageInMemoryMetadata const&, DB::StorageInMemoryMetadata const&, bool, bool, bool, bool, std::shared_ptr) const @ 0x0000000016307fa2 7. /build/src/Storages/MergeTree/MergeTreeData.cpp:868: DB::MergeTreeData::setProperties(DB::StorageInMemoryMetadata const&, DB::StorageInMemoryMetadata const&, bool, std::shared_ptr) @ 0x000000001630257f 8. /build/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) @ 0x00000000163014fc 9. /build/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>) @ 0x0000000016632995 10. /build/contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: std::shared_ptr std::allocate_shared[abi:se190107], 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>&&) @ 0x00000000166326f0 11. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:851: DB::create(DB::StorageFactory::Arguments const&) @ 0x000000001662f01d 12. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000015d81ea2 13. /build/src/Interpreters/InterpreterCreateQuery.cpp:1945: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x00000000149009bb 14. /build/src/Interpreters/InterpreterCreateQuery.cpp:1743: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000148f9aa9 15. /build/src/Interpreters/InterpreterCreateQuery.cpp:2352: DB::InterpreterCreateQuery::execute() @ 0x0000000014905a41 16. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88dc9 17. /build/src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x0000000014c8ca7b 18. /build/src/Interpreters/DDLWorker.cpp:510: DB::DDLWorker::tryExecuteQuery(DB::DDLTaskBase&, std::shared_ptr const&, bool) @ 0x00000000144dab9e 19. /build/src/Interpreters/DDLWorker.cpp:675: DB::DDLWorker::processTask(DB::DDLTaskBase&, std::shared_ptr const&, bool) @ 0x00000000144d8ffe 20. /build/src/Databases/DatabaseReplicatedWorker.cpp:372: DB::DatabaseReplicatedDDLWorker::tryEnqueueAndExecuteEntry(DB::DDLLogEntry&, std::shared_ptr, bool) @ 0x0000000013dc29ab 21. /build/src/Databases/DatabaseReplicated.cpp:1139: DB::DatabaseReplicated::tryEnqueueReplicatedDDL(std::shared_ptr const&, std::shared_ptr, DB::QueryFlags) @ 0x0000000013d9f73c 22. /build/src/Interpreters/InterpreterCreateQuery.cpp:1723: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000148f96f8 23. /build/src/Interpreters/InterpreterCreateQuery.cpp:2352: DB::InterpreterCreateQuery::execute() @ 0x0000000014905a41 24. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88dc9 25. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 26. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 27. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 28. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 29. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 30. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 31. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 2025.07.28 12:00:35.514961 [ 4900 ] {} TCPHandler: Code: 36. DB::Exception: The size of bloom filter cannot be zero. (BAD_ARGUMENTS), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000000a074fcb 4. /build/src/Interpreters/BloomFilter.cpp:28: DB::BloomFilterParameters::BloomFilterParameters(unsigned long, unsigned long, unsigned long) @ 0x00000000143f66cf 5. /build/src/Storages/MergeTree/MergeTreeIndexBloomFilterText.cpp:814: DB::bloomFilterIndexTextValidator(DB::IndexDescription const&, bool) @ 0x0000000016442fea 6. /build/src/Storages/MergeTree/MergeTreeData.cpp:807: DB::MergeTreeData::checkProperties(DB::StorageInMemoryMetadata const&, DB::StorageInMemoryMetadata const&, bool, bool, bool, bool, std::shared_ptr) const @ 0x0000000016307fa2 7. /build/src/Storages/MergeTree/MergeTreeData.cpp:868: DB::MergeTreeData::setProperties(DB::StorageInMemoryMetadata const&, DB::StorageInMemoryMetadata const&, bool, std::shared_ptr) @ 0x000000001630257f 8. /build/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) @ 0x00000000163014fc 9. /build/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>) @ 0x0000000016632995 10. /build/contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: std::shared_ptr std::allocate_shared[abi:se190107], 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>&&) @ 0x00000000166326f0 11. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:851: DB::create(DB::StorageFactory::Arguments const&) @ 0x000000001662f01d 12. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000015d81ea2 13. /build/src/Interpreters/InterpreterCreateQuery.cpp:1945: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x00000000149009bb 14. /build/src/Interpreters/InterpreterCreateQuery.cpp:1743: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000148f9aa9 15. /build/src/Interpreters/InterpreterCreateQuery.cpp:2352: DB::InterpreterCreateQuery::execute() @ 0x0000000014905a41 16. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88dc9 17. /build/src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x0000000014c8ca7b 18. /build/src/Interpreters/DDLWorker.cpp:510: DB::DDLWorker::tryExecuteQuery(DB::DDLTaskBase&, std::shared_ptr const&, bool) @ 0x00000000144dab9e 19. /build/src/Interpreters/DDLWorker.cpp:675: DB::DDLWorker::processTask(DB::DDLTaskBase&, std::shared_ptr const&, bool) @ 0x00000000144d8ffe 20. /build/src/Databases/DatabaseReplicatedWorker.cpp:372: DB::DatabaseReplicatedDDLWorker::tryEnqueueAndExecuteEntry(DB::DDLLogEntry&, std::shared_ptr, bool) @ 0x0000000013dc29ab 21. /build/src/Databases/DatabaseReplicated.cpp:1139: DB::DatabaseReplicated::tryEnqueueReplicatedDDL(std::shared_ptr const&, std::shared_ptr, DB::QueryFlags) @ 0x0000000013d9f73c 22. /build/src/Interpreters/InterpreterCreateQuery.cpp:1723: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000148f96f8 23. /build/src/Interpreters/InterpreterCreateQuery.cpp:2352: DB::InterpreterCreateQuery::execute() @ 0x0000000014905a41 24. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88dc9 25. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 26. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 27. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 28. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 29. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 30. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 31. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 2025.07.28 12:00:35.746916 [ 3971 ] {} test_13.rmt2 (7f9b740d-015c-470e-8cc6-8ba33be0dc63): auto DB::StorageReplicatedMergeTree::processQueueEntry(ReplicatedMergeTreeQueue::SelectedEntryPtr)::(anonymous class)::operator()(LogEntryPtr &) const: Code: 86. DB::HTTPException: Received error from remote server http://146b4357c08d:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Ftest%2F01165%2Ftest_13%2Frmt%2Freplicas%2F1&part=20250728_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.6.10636.altinitytest (altinity build)) '. (RECEIVED_ERROR_FROM_REMOTE_IO_SERVER), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.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 const&, int&&, String const&, unsigned long&&, String const&) @ 0x000000000feda8d9 4. /build/src/IO/HTTPCommon.cpp:104: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x000000000feda6e2 5. /build/src/IO/HTTPCommon.cpp:93: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x000000000feda537 6. /build/src/IO/ReadWriteBufferFromHTTP.cpp:277: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x000000001184a4c4 7. /build/src/IO/ReadWriteBufferFromHTTP.cpp:285: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x000000001184a615 8. /build/src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x000000001184ae59 9. /build/src/IO/ReadWriteBufferFromHTTP.cpp:472: void std::__function::__policy_invoker::__call_impl[abi:se190107]>(std::__function::__policy_storage const*) @ 0x000000001184cedd 10. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001184858b 11. /build/src/IO/ReadWriteBufferFromHTTP.cpp:465: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x000000001184bf0b 12. /build/src/IO/ReadBuffer.h:60: DB::ReadBuffer::next() @ 0x000000000a148c7b 13. /build/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) @ 0x0000000011849fb2 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]>&)>&, 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&) @ 0x0000000011841980 15. /build/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) @ 0x000000001621208e 16. /build/src/Storages/StorageReplicatedMergeTree.cpp:5228: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl[abi:se190107] const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000015f9a5fe 17. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000015ed8bfd 18. /build/src/Storages/StorageReplicatedMergeTree.cpp:2514: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x0000000015ec9aab 19. /build/src/Storages/StorageReplicatedMergeTree.cpp:2349: DB::StorageReplicatedMergeTree::executeLogEntry(DB::ReplicatedMergeTreeLogEntry&) @ 0x0000000015eba91b 20. /build/src/Storages/StorageReplicatedMergeTree.cpp:3876: bool std::__function::__policy_invoker&)>::__call_impl[abi:se190107])::$_1, bool (std::shared_ptr&)>>(std::__function::__policy_storage const*, std::shared_ptr&) @ 0x0000000015f9837e 21. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000165d6fc3 22. /build/src/Storages/StorageReplicatedMergeTree.cpp:3872: DB::StorageReplicatedMergeTree::processQueueEntry(std::shared_ptr) @ 0x0000000015efc18a 23. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001624c1b2 24. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000162f9c70 25. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x00000000162fa55a 26. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc6653 27. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000000fccc4c3 28. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc3d92 29. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fcca080 30. ? @ 0x00007fbc6213eac3 31. ? @ 0x00007fbc621d0850 (version 25.3.6.10636.altinitytest (altinity build)) 2025.07.28 12:00:35.853080 [ 4900 ] {ed5c4c67-2d96-44c3-afce-d2bf2d695dcc} executeQuery: Code: 36. DB::Exception: The number of hash functions for bloom filter cannot be zero. (BAD_ARGUMENTS) (version 25.3.6.10636.altinitytest (altinity build)) (from 0.0.0.0:0) (comment: 01384_bloom_filter_bad_arguments.sql) (in query: /* ddl_entry=query-0000000140 */ CREATE TABLE test_5.test UUID '68562e99-aafb-44fa-a041-d69c5fc6d111' (`a` String, INDEX a a TYPE tokenbf_v1(2, 0, 0) GRANULARITY 1) ENGINE = MergeTree ORDER BY a SETTINGS index_granularity = 31235, 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 = 258222230, compact_parts_max_bytes_to_buffer = 472164226, compact_parts_max_granules_to_buffer = 119, compact_parts_merge_max_bytes_to_prefetch_part = 17681283, merge_max_block_size = 2282, old_parts_lifetime = 480., prefer_fetch_merged_part_size_threshold = 10737418240, vertical_merge_algorithm_min_rows_to_activate = 387269, vertical_merge_algorithm_min_columns_to_activate = 100, min_merge_bytes_to_use_direct_io = 10737418240, index_granularity_bytes = 16941609, use_const_adaptive_granularity = true, enable_index_granularity_compression = false, concurrent_part_removal_threshold = 91, 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 = 59202, primary_key_compress_block_size = 46175, 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. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000000a074fcb 4. /build/src/Interpreters/BloomFilter.cpp:30: DB::BloomFilterParameters::BloomFilterParameters(unsigned long, unsigned long, unsigned long) @ 0x00000000143f6728 5. /build/src/Storages/MergeTree/MergeTreeIndexBloomFilterText.cpp:814: DB::bloomFilterIndexTextValidator(DB::IndexDescription const&, bool) @ 0x0000000016442fea 6. /build/src/Storages/MergeTree/MergeTreeData.cpp:807: DB::MergeTreeData::checkProperties(DB::StorageInMemoryMetadata const&, DB::StorageInMemoryMetadata const&, bool, bool, bool, bool, std::shared_ptr) const @ 0x0000000016307fa2 7. /build/src/Storages/MergeTree/MergeTreeData.cpp:868: DB::MergeTreeData::setProperties(DB::StorageInMemoryMetadata const&, DB::StorageInMemoryMetadata const&, bool, std::shared_ptr) @ 0x000000001630257f 8. /build/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) @ 0x00000000163014fc 9. /build/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>) @ 0x0000000016632995 10. /build/contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: std::shared_ptr std::allocate_shared[abi:se190107], 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>&&) @ 0x00000000166326f0 11. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:851: DB::create(DB::StorageFactory::Arguments const&) @ 0x000000001662f01d 12. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000015d81ea2 13. /build/src/Interpreters/InterpreterCreateQuery.cpp:1945: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x00000000149009bb 14. /build/src/Interpreters/InterpreterCreateQuery.cpp:1743: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000148f9aa9 15. /build/src/Interpreters/InterpreterCreateQuery.cpp:2352: DB::InterpreterCreateQuery::execute() @ 0x0000000014905a41 16. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88dc9 17. /build/src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x0000000014c8ca7b 18. /build/src/Interpreters/DDLWorker.cpp:510: DB::DDLWorker::tryExecuteQuery(DB::DDLTaskBase&, std::shared_ptr const&, bool) @ 0x00000000144dab9e 19. /build/src/Interpreters/DDLWorker.cpp:675: DB::DDLWorker::processTask(DB::DDLTaskBase&, std::shared_ptr const&, bool) @ 0x00000000144d8ffe 20. /build/src/Databases/DatabaseReplicatedWorker.cpp:372: DB::DatabaseReplicatedDDLWorker::tryEnqueueAndExecuteEntry(DB::DDLLogEntry&, std::shared_ptr, bool) @ 0x0000000013dc29ab 21. /build/src/Databases/DatabaseReplicated.cpp:1139: DB::DatabaseReplicated::tryEnqueueReplicatedDDL(std::shared_ptr const&, std::shared_ptr, DB::QueryFlags) @ 0x0000000013d9f73c 22. /build/src/Interpreters/InterpreterCreateQuery.cpp:1723: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000148f96f8 23. /build/src/Interpreters/InterpreterCreateQuery.cpp:2352: DB::InterpreterCreateQuery::execute() @ 0x0000000014905a41 24. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88dc9 25. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 26. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 27. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 28. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 29. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 30. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 31. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 2025.07.28 12:00:35.987316 [ 4900 ] {ed5c4c67-2d96-44c3-afce-d2bf2d695dcc} executeQuery: Code: 36. DB::Exception: The number of hash functions for bloom filter cannot be zero. (BAD_ARGUMENTS) (version 25.3.6.10636.altinitytest (altinity build)) (from [::1]:43270) (comment: 01384_bloom_filter_bad_arguments.sql) (query 3, line 4) (in query: CREATE TABLE test (`a` String, INDEX a a TYPE tokenbf_v1(2, 0, 0) GRANULARITY 1) ENGINE = MergeTree ORDER BY a SETTINGS index_granularity = 31235, 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 = 258222230, compact_parts_max_bytes_to_buffer = 472164226, compact_parts_max_granules_to_buffer = 119, compact_parts_merge_max_bytes_to_prefetch_part = 17681283, merge_max_block_size = 2282, old_parts_lifetime = 480., prefer_fetch_merged_part_size_threshold = 10737418240, vertical_merge_algorithm_min_rows_to_activate = 387269, vertical_merge_algorithm_min_columns_to_activate = 100, min_merge_bytes_to_use_direct_io = 10737418240, index_granularity_bytes = 16941609, use_const_adaptive_granularity = true, enable_index_granularity_compression = false, concurrent_part_removal_threshold = 91, 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 = 59202, primary_key_compress_block_size = 46175, 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. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000000a074fcb 4. /build/src/Interpreters/BloomFilter.cpp:30: DB::BloomFilterParameters::BloomFilterParameters(unsigned long, unsigned long, unsigned long) @ 0x00000000143f6728 5. /build/src/Storages/MergeTree/MergeTreeIndexBloomFilterText.cpp:814: DB::bloomFilterIndexTextValidator(DB::IndexDescription const&, bool) @ 0x0000000016442fea 6. /build/src/Storages/MergeTree/MergeTreeData.cpp:807: DB::MergeTreeData::checkProperties(DB::StorageInMemoryMetadata const&, DB::StorageInMemoryMetadata const&, bool, bool, bool, bool, std::shared_ptr) const @ 0x0000000016307fa2 7. /build/src/Storages/MergeTree/MergeTreeData.cpp:868: DB::MergeTreeData::setProperties(DB::StorageInMemoryMetadata const&, DB::StorageInMemoryMetadata const&, bool, std::shared_ptr) @ 0x000000001630257f 8. /build/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) @ 0x00000000163014fc 9. /build/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>) @ 0x0000000016632995 10. /build/contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: std::shared_ptr std::allocate_shared[abi:se190107], 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>&&) @ 0x00000000166326f0 11. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:851: DB::create(DB::StorageFactory::Arguments const&) @ 0x000000001662f01d 12. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000015d81ea2 13. /build/src/Interpreters/InterpreterCreateQuery.cpp:1945: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x00000000149009bb 14. /build/src/Interpreters/InterpreterCreateQuery.cpp:1743: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000148f9aa9 15. /build/src/Interpreters/InterpreterCreateQuery.cpp:2352: DB::InterpreterCreateQuery::execute() @ 0x0000000014905a41 16. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88dc9 17. /build/src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x0000000014c8ca7b 18. /build/src/Interpreters/DDLWorker.cpp:510: DB::DDLWorker::tryExecuteQuery(DB::DDLTaskBase&, std::shared_ptr const&, bool) @ 0x00000000144dab9e 19. /build/src/Interpreters/DDLWorker.cpp:675: DB::DDLWorker::processTask(DB::DDLTaskBase&, std::shared_ptr const&, bool) @ 0x00000000144d8ffe 20. /build/src/Databases/DatabaseReplicatedWorker.cpp:372: DB::DatabaseReplicatedDDLWorker::tryEnqueueAndExecuteEntry(DB::DDLLogEntry&, std::shared_ptr, bool) @ 0x0000000013dc29ab 21. /build/src/Databases/DatabaseReplicated.cpp:1139: DB::DatabaseReplicated::tryEnqueueReplicatedDDL(std::shared_ptr const&, std::shared_ptr, DB::QueryFlags) @ 0x0000000013d9f73c 22. /build/src/Interpreters/InterpreterCreateQuery.cpp:1723: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000148f96f8 23. /build/src/Interpreters/InterpreterCreateQuery.cpp:2352: DB::InterpreterCreateQuery::execute() @ 0x0000000014905a41 24. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88dc9 25. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 26. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 27. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 28. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 29. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 30. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 31. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 2025.07.28 12:00:35.989901 [ 4900 ] {} TCPHandler: Code: 36. DB::Exception: The number of hash functions for bloom filter cannot be zero. (BAD_ARGUMENTS), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000000a074fcb 4. /build/src/Interpreters/BloomFilter.cpp:30: DB::BloomFilterParameters::BloomFilterParameters(unsigned long, unsigned long, unsigned long) @ 0x00000000143f6728 5. /build/src/Storages/MergeTree/MergeTreeIndexBloomFilterText.cpp:814: DB::bloomFilterIndexTextValidator(DB::IndexDescription const&, bool) @ 0x0000000016442fea 6. /build/src/Storages/MergeTree/MergeTreeData.cpp:807: DB::MergeTreeData::checkProperties(DB::StorageInMemoryMetadata const&, DB::StorageInMemoryMetadata const&, bool, bool, bool, bool, std::shared_ptr) const @ 0x0000000016307fa2 7. /build/src/Storages/MergeTree/MergeTreeData.cpp:868: DB::MergeTreeData::setProperties(DB::StorageInMemoryMetadata const&, DB::StorageInMemoryMetadata const&, bool, std::shared_ptr) @ 0x000000001630257f 8. /build/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) @ 0x00000000163014fc 9. /build/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>) @ 0x0000000016632995 10. /build/contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: std::shared_ptr std::allocate_shared[abi:se190107], 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>&&) @ 0x00000000166326f0 11. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:851: DB::create(DB::StorageFactory::Arguments const&) @ 0x000000001662f01d 12. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000015d81ea2 13. /build/src/Interpreters/InterpreterCreateQuery.cpp:1945: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x00000000149009bb 14. /build/src/Interpreters/InterpreterCreateQuery.cpp:1743: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000148f9aa9 15. /build/src/Interpreters/InterpreterCreateQuery.cpp:2352: DB::InterpreterCreateQuery::execute() @ 0x0000000014905a41 16. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88dc9 17. /build/src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x0000000014c8ca7b 18. /build/src/Interpreters/DDLWorker.cpp:510: DB::DDLWorker::tryExecuteQuery(DB::DDLTaskBase&, std::shared_ptr const&, bool) @ 0x00000000144dab9e 19. /build/src/Interpreters/DDLWorker.cpp:675: DB::DDLWorker::processTask(DB::DDLTaskBase&, std::shared_ptr const&, bool) @ 0x00000000144d8ffe 20. /build/src/Databases/DatabaseReplicatedWorker.cpp:372: DB::DatabaseReplicatedDDLWorker::tryEnqueueAndExecuteEntry(DB::DDLLogEntry&, std::shared_ptr, bool) @ 0x0000000013dc29ab 21. /build/src/Databases/DatabaseReplicated.cpp:1139: DB::DatabaseReplicated::tryEnqueueReplicatedDDL(std::shared_ptr const&, std::shared_ptr, DB::QueryFlags) @ 0x0000000013d9f73c 22. /build/src/Interpreters/InterpreterCreateQuery.cpp:1723: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000148f96f8 23. /build/src/Interpreters/InterpreterCreateQuery.cpp:2352: DB::InterpreterCreateQuery::execute() @ 0x0000000014905a41 24. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88dc9 25. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 26. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 27. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 28. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 29. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 30. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 31. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 2025.07.28 12:00:36.037084 [ 3965 ] {} test_13.rmt2 (7f9b740d-015c-470e-8cc6-8ba33be0dc63): auto DB::StorageReplicatedMergeTree::processQueueEntry(ReplicatedMergeTreeQueue::SelectedEntryPtr)::(anonymous class)::operator()(LogEntryPtr &) const: Code: 86. DB::HTTPException: Received error from remote server http://146b4357c08d:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Ftest%2F01165%2Ftest_13%2Frmt%2Freplicas%2F1&part=20250728_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.6.10636.altinitytest (altinity build)) '. (RECEIVED_ERROR_FROM_REMOTE_IO_SERVER), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.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 const&, int&&, String const&, unsigned long&&, String const&) @ 0x000000000feda8d9 4. /build/src/IO/HTTPCommon.cpp:104: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x000000000feda6e2 5. /build/src/IO/HTTPCommon.cpp:93: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x000000000feda537 6. /build/src/IO/ReadWriteBufferFromHTTP.cpp:277: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x000000001184a4c4 7. /build/src/IO/ReadWriteBufferFromHTTP.cpp:285: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x000000001184a615 8. /build/src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x000000001184ae59 9. /build/src/IO/ReadWriteBufferFromHTTP.cpp:472: void std::__function::__policy_invoker::__call_impl[abi:se190107]>(std::__function::__policy_storage const*) @ 0x000000001184cedd 10. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001184858b 11. /build/src/IO/ReadWriteBufferFromHTTP.cpp:465: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x000000001184bf0b 12. /build/src/IO/ReadBuffer.h:60: DB::ReadBuffer::next() @ 0x000000000a148c7b 13. /build/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) @ 0x0000000011849fb2 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]>&)>&, 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&) @ 0x0000000011841980 15. /build/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) @ 0x000000001621208e 16. /build/src/Storages/StorageReplicatedMergeTree.cpp:5228: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl[abi:se190107] const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000015f9a5fe 17. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000015ed8bfd 18. /build/src/Storages/StorageReplicatedMergeTree.cpp:2514: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x0000000015ec9aab 19. /build/src/Storages/StorageReplicatedMergeTree.cpp:2349: DB::StorageReplicatedMergeTree::executeLogEntry(DB::ReplicatedMergeTreeLogEntry&) @ 0x0000000015eba91b 20. /build/src/Storages/StorageReplicatedMergeTree.cpp:3876: bool std::__function::__policy_invoker&)>::__call_impl[abi:se190107])::$_1, bool (std::shared_ptr&)>>(std::__function::__policy_storage const*, std::shared_ptr&) @ 0x0000000015f9837e 21. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000165d6fc3 22. /build/src/Storages/StorageReplicatedMergeTree.cpp:3872: DB::StorageReplicatedMergeTree::processQueueEntry(std::shared_ptr) @ 0x0000000015efc18a 23. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001624c1b2 24. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000162f9c70 25. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x00000000162fa55a 26. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc6653 27. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000000fccc4c3 28. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc3d92 29. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fcca080 30. ? @ 0x00007fbc6213eac3 31. ? @ 0x00007fbc621d0850 (version 25.3.6.10636.altinitytest (altinity build)) 2025.07.28 12:00:36.268010 [ 4900 ] {b9f67aa7-57b5-4434-9ac5-e1ed6c14b250} executeQuery: Code: 36. DB::Exception: The size of bloom filter cannot be zero. (BAD_ARGUMENTS) (version 25.3.6.10636.altinitytest (altinity build)) (from 0.0.0.0:0) (comment: 01384_bloom_filter_bad_arguments.sql) (in query: /* ddl_entry=query-0000000141 */ CREATE TABLE test_5.test UUID '710ebfbd-c71c-4cb3-8ec2-ae808f6a1fe2' (`a` String, INDEX a a TYPE tokenbf_v1(0, 1, 1) GRANULARITY 1) ENGINE = MergeTree ORDER BY a SETTINGS index_granularity = 31235, 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 = 258222230, compact_parts_max_bytes_to_buffer = 472164226, compact_parts_max_granules_to_buffer = 119, compact_parts_merge_max_bytes_to_prefetch_part = 17681283, merge_max_block_size = 2282, old_parts_lifetime = 480., prefer_fetch_merged_part_size_threshold = 10737418240, vertical_merge_algorithm_min_rows_to_activate = 387269, vertical_merge_algorithm_min_columns_to_activate = 100, min_merge_bytes_to_use_direct_io = 10737418240, index_granularity_bytes = 16941609, use_const_adaptive_granularity = true, enable_index_granularity_compression = false, concurrent_part_removal_threshold = 91, 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 = 59202, primary_key_compress_block_size = 46175, 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. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000000a074fcb 4. /build/src/Interpreters/BloomFilter.cpp:28: DB::BloomFilterParameters::BloomFilterParameters(unsigned long, unsigned long, unsigned long) @ 0x00000000143f66cf 5. /build/src/Storages/MergeTree/MergeTreeIndexBloomFilterText.cpp:814: DB::bloomFilterIndexTextValidator(DB::IndexDescription const&, bool) @ 0x0000000016442fea 6. /build/src/Storages/MergeTree/MergeTreeData.cpp:807: DB::MergeTreeData::checkProperties(DB::StorageInMemoryMetadata const&, DB::StorageInMemoryMetadata const&, bool, bool, bool, bool, std::shared_ptr) const @ 0x0000000016307fa2 7. /build/src/Storages/MergeTree/MergeTreeData.cpp:868: DB::MergeTreeData::setProperties(DB::StorageInMemoryMetadata const&, DB::StorageInMemoryMetadata const&, bool, std::shared_ptr) @ 0x000000001630257f 8. /build/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) @ 0x00000000163014fc 9. /build/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>) @ 0x0000000016632995 10. /build/contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: std::shared_ptr std::allocate_shared[abi:se190107], 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>&&) @ 0x00000000166326f0 11. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:851: DB::create(DB::StorageFactory::Arguments const&) @ 0x000000001662f01d 12. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000015d81ea2 13. /build/src/Interpreters/InterpreterCreateQuery.cpp:1945: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x00000000149009bb 14. /build/src/Interpreters/InterpreterCreateQuery.cpp:1743: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000148f9aa9 15. /build/src/Interpreters/InterpreterCreateQuery.cpp:2352: DB::InterpreterCreateQuery::execute() @ 0x0000000014905a41 16. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88dc9 17. /build/src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x0000000014c8ca7b 18. /build/src/Interpreters/DDLWorker.cpp:510: DB::DDLWorker::tryExecuteQuery(DB::DDLTaskBase&, std::shared_ptr const&, bool) @ 0x00000000144dab9e 19. /build/src/Interpreters/DDLWorker.cpp:675: DB::DDLWorker::processTask(DB::DDLTaskBase&, std::shared_ptr const&, bool) @ 0x00000000144d8ffe 20. /build/src/Databases/DatabaseReplicatedWorker.cpp:372: DB::DatabaseReplicatedDDLWorker::tryEnqueueAndExecuteEntry(DB::DDLLogEntry&, std::shared_ptr, bool) @ 0x0000000013dc29ab 21. /build/src/Databases/DatabaseReplicated.cpp:1139: DB::DatabaseReplicated::tryEnqueueReplicatedDDL(std::shared_ptr const&, std::shared_ptr, DB::QueryFlags) @ 0x0000000013d9f73c 22. /build/src/Interpreters/InterpreterCreateQuery.cpp:1723: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000148f96f8 23. /build/src/Interpreters/InterpreterCreateQuery.cpp:2352: DB::InterpreterCreateQuery::execute() @ 0x0000000014905a41 24. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88dc9 25. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 26. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 27. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 28. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 29. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 30. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 31. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 2025.07.28 12:00:36.302091 [ 4900 ] {b9f67aa7-57b5-4434-9ac5-e1ed6c14b250} executeQuery: Code: 36. DB::Exception: The size of bloom filter cannot be zero. (BAD_ARGUMENTS) (version 25.3.6.10636.altinitytest (altinity build)) (from [::1]:43270) (comment: 01384_bloom_filter_bad_arguments.sql) (query 4, line 5) (in query: CREATE TABLE test (`a` String, INDEX a a TYPE tokenbf_v1(0, 1, 1) GRANULARITY 1) ENGINE = MergeTree ORDER BY a SETTINGS index_granularity = 31235, 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 = 258222230, compact_parts_max_bytes_to_buffer = 472164226, compact_parts_max_granules_to_buffer = 119, compact_parts_merge_max_bytes_to_prefetch_part = 17681283, merge_max_block_size = 2282, old_parts_lifetime = 480., prefer_fetch_merged_part_size_threshold = 10737418240, vertical_merge_algorithm_min_rows_to_activate = 387269, vertical_merge_algorithm_min_columns_to_activate = 100, min_merge_bytes_to_use_direct_io = 10737418240, index_granularity_bytes = 16941609, use_const_adaptive_granularity = true, enable_index_granularity_compression = false, concurrent_part_removal_threshold = 91, 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 = 59202, primary_key_compress_block_size = 46175, 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. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000000a074fcb 4. /build/src/Interpreters/BloomFilter.cpp:28: DB::BloomFilterParameters::BloomFilterParameters(unsigned long, unsigned long, unsigned long) @ 0x00000000143f66cf 5. /build/src/Storages/MergeTree/MergeTreeIndexBloomFilterText.cpp:814: DB::bloomFilterIndexTextValidator(DB::IndexDescription const&, bool) @ 0x0000000016442fea 6. /build/src/Storages/MergeTree/MergeTreeData.cpp:807: DB::MergeTreeData::checkProperties(DB::StorageInMemoryMetadata const&, DB::StorageInMemoryMetadata const&, bool, bool, bool, bool, std::shared_ptr) const @ 0x0000000016307fa2 7. /build/src/Storages/MergeTree/MergeTreeData.cpp:868: DB::MergeTreeData::setProperties(DB::StorageInMemoryMetadata const&, DB::StorageInMemoryMetadata const&, bool, std::shared_ptr) @ 0x000000001630257f 8. /build/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) @ 0x00000000163014fc 9. /build/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>) @ 0x0000000016632995 10. /build/contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: std::shared_ptr std::allocate_shared[abi:se190107], 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>&&) @ 0x00000000166326f0 11. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:851: DB::create(DB::StorageFactory::Arguments const&) @ 0x000000001662f01d 12. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000015d81ea2 13. /build/src/Interpreters/InterpreterCreateQuery.cpp:1945: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x00000000149009bb 14. /build/src/Interpreters/InterpreterCreateQuery.cpp:1743: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000148f9aa9 15. /build/src/Interpreters/InterpreterCreateQuery.cpp:2352: DB::InterpreterCreateQuery::execute() @ 0x0000000014905a41 16. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88dc9 17. /build/src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x0000000014c8ca7b 18. /build/src/Interpreters/DDLWorker.cpp:510: DB::DDLWorker::tryExecuteQuery(DB::DDLTaskBase&, std::shared_ptr const&, bool) @ 0x00000000144dab9e 19. /build/src/Interpreters/DDLWorker.cpp:675: DB::DDLWorker::processTask(DB::DDLTaskBase&, std::shared_ptr const&, bool) @ 0x00000000144d8ffe 20. /build/src/Databases/DatabaseReplicatedWorker.cpp:372: DB::DatabaseReplicatedDDLWorker::tryEnqueueAndExecuteEntry(DB::DDLLogEntry&, std::shared_ptr, bool) @ 0x0000000013dc29ab 21. /build/src/Databases/DatabaseReplicated.cpp:1139: DB::DatabaseReplicated::tryEnqueueReplicatedDDL(std::shared_ptr const&, std::shared_ptr, DB::QueryFlags) @ 0x0000000013d9f73c 22. /build/src/Interpreters/InterpreterCreateQuery.cpp:1723: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000148f96f8 23. /build/src/Interpreters/InterpreterCreateQuery.cpp:2352: DB::InterpreterCreateQuery::execute() @ 0x0000000014905a41 24. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88dc9 25. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 26. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 27. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 28. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 29. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 30. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 31. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 2025.07.28 12:00:36.321919 [ 4900 ] {} TCPHandler: Code: 36. DB::Exception: The size of bloom filter cannot be zero. (BAD_ARGUMENTS), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000000a074fcb 4. /build/src/Interpreters/BloomFilter.cpp:28: DB::BloomFilterParameters::BloomFilterParameters(unsigned long, unsigned long, unsigned long) @ 0x00000000143f66cf 5. /build/src/Storages/MergeTree/MergeTreeIndexBloomFilterText.cpp:814: DB::bloomFilterIndexTextValidator(DB::IndexDescription const&, bool) @ 0x0000000016442fea 6. /build/src/Storages/MergeTree/MergeTreeData.cpp:807: DB::MergeTreeData::checkProperties(DB::StorageInMemoryMetadata const&, DB::StorageInMemoryMetadata const&, bool, bool, bool, bool, std::shared_ptr) const @ 0x0000000016307fa2 7. /build/src/Storages/MergeTree/MergeTreeData.cpp:868: DB::MergeTreeData::setProperties(DB::StorageInMemoryMetadata const&, DB::StorageInMemoryMetadata const&, bool, std::shared_ptr) @ 0x000000001630257f 8. /build/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) @ 0x00000000163014fc 9. /build/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>) @ 0x0000000016632995 10. /build/contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: std::shared_ptr std::allocate_shared[abi:se190107], 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>&&) @ 0x00000000166326f0 11. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:851: DB::create(DB::StorageFactory::Arguments const&) @ 0x000000001662f01d 12. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000015d81ea2 13. /build/src/Interpreters/InterpreterCreateQuery.cpp:1945: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x00000000149009bb 14. /build/src/Interpreters/InterpreterCreateQuery.cpp:1743: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000148f9aa9 15. /build/src/Interpreters/InterpreterCreateQuery.cpp:2352: DB::InterpreterCreateQuery::execute() @ 0x0000000014905a41 16. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88dc9 17. /build/src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x0000000014c8ca7b 18. /build/src/Interpreters/DDLWorker.cpp:510: DB::DDLWorker::tryExecuteQuery(DB::DDLTaskBase&, std::shared_ptr const&, bool) @ 0x00000000144dab9e 19. /build/src/Interpreters/DDLWorker.cpp:675: DB::DDLWorker::processTask(DB::DDLTaskBase&, std::shared_ptr const&, bool) @ 0x00000000144d8ffe 20. /build/src/Databases/DatabaseReplicatedWorker.cpp:372: DB::DatabaseReplicatedDDLWorker::tryEnqueueAndExecuteEntry(DB::DDLLogEntry&, std::shared_ptr, bool) @ 0x0000000013dc29ab 21. /build/src/Databases/DatabaseReplicated.cpp:1139: DB::DatabaseReplicated::tryEnqueueReplicatedDDL(std::shared_ptr const&, std::shared_ptr, DB::QueryFlags) @ 0x0000000013d9f73c 22. /build/src/Interpreters/InterpreterCreateQuery.cpp:1723: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000148f96f8 23. /build/src/Interpreters/InterpreterCreateQuery.cpp:2352: DB::InterpreterCreateQuery::execute() @ 0x0000000014905a41 24. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88dc9 25. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 26. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 27. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 28. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 29. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 30. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 31. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 2025.07.28 12:00:36.655566 [ 4900 ] {2dea0e53-67db-405c-9700-b5cdec0d741a} executeQuery: Code: 36. DB::Exception: The number of hash functions for bloom filter cannot be zero. (BAD_ARGUMENTS) (version 25.3.6.10636.altinitytest (altinity build)) (from 0.0.0.0:0) (comment: 01384_bloom_filter_bad_arguments.sql) (in query: /* ddl_entry=query-0000000142 */ CREATE TABLE test_5.test UUID '799b5d01-15d3-4915-ba75-c0af83d2a791' (`a` String, INDEX a a TYPE tokenbf_v1(1, 0, 1) GRANULARITY 1) ENGINE = MergeTree ORDER BY a SETTINGS index_granularity = 31235, 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 = 258222230, compact_parts_max_bytes_to_buffer = 472164226, compact_parts_max_granules_to_buffer = 119, compact_parts_merge_max_bytes_to_prefetch_part = 17681283, merge_max_block_size = 2282, old_parts_lifetime = 480., prefer_fetch_merged_part_size_threshold = 10737418240, vertical_merge_algorithm_min_rows_to_activate = 387269, vertical_merge_algorithm_min_columns_to_activate = 100, min_merge_bytes_to_use_direct_io = 10737418240, index_granularity_bytes = 16941609, use_const_adaptive_granularity = true, enable_index_granularity_compression = false, concurrent_part_removal_threshold = 91, 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 = 59202, primary_key_compress_block_size = 46175, 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. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000000a074fcb 4. /build/src/Interpreters/BloomFilter.cpp:30: DB::BloomFilterParameters::BloomFilterParameters(unsigned long, unsigned long, unsigned long) @ 0x00000000143f6728 5. /build/src/Storages/MergeTree/MergeTreeIndexBloomFilterText.cpp:814: DB::bloomFilterIndexTextValidator(DB::IndexDescription const&, bool) @ 0x0000000016442fea 6. /build/src/Storages/MergeTree/MergeTreeData.cpp:807: DB::MergeTreeData::checkProperties(DB::StorageInMemoryMetadata const&, DB::StorageInMemoryMetadata const&, bool, bool, bool, bool, std::shared_ptr) const @ 0x0000000016307fa2 7. /build/src/Storages/MergeTree/MergeTreeData.cpp:868: DB::MergeTreeData::setProperties(DB::StorageInMemoryMetadata const&, DB::StorageInMemoryMetadata const&, bool, std::shared_ptr) @ 0x000000001630257f 8. /build/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) @ 0x00000000163014fc 9. /build/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>) @ 0x0000000016632995 10. /build/contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: std::shared_ptr std::allocate_shared[abi:se190107], 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>&&) @ 0x00000000166326f0 11. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:851: DB::create(DB::StorageFactory::Arguments const&) @ 0x000000001662f01d 12. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000015d81ea2 13. /build/src/Interpreters/InterpreterCreateQuery.cpp:1945: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x00000000149009bb 14. /build/src/Interpreters/InterpreterCreateQuery.cpp:1743: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000148f9aa9 15. /build/src/Interpreters/InterpreterCreateQuery.cpp:2352: DB::InterpreterCreateQuery::execute() @ 0x0000000014905a41 16. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88dc9 17. /build/src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x0000000014c8ca7b 18. /build/src/Interpreters/DDLWorker.cpp:510: DB::DDLWorker::tryExecuteQuery(DB::DDLTaskBase&, std::shared_ptr const&, bool) @ 0x00000000144dab9e 19. /build/src/Interpreters/DDLWorker.cpp:675: DB::DDLWorker::processTask(DB::DDLTaskBase&, std::shared_ptr const&, bool) @ 0x00000000144d8ffe 20. /build/src/Databases/DatabaseReplicatedWorker.cpp:372: DB::DatabaseReplicatedDDLWorker::tryEnqueueAndExecuteEntry(DB::DDLLogEntry&, std::shared_ptr, bool) @ 0x0000000013dc29ab 21. /build/src/Databases/DatabaseReplicated.cpp:1139: DB::DatabaseReplicated::tryEnqueueReplicatedDDL(std::shared_ptr const&, std::shared_ptr, DB::QueryFlags) @ 0x0000000013d9f73c 22. /build/src/Interpreters/InterpreterCreateQuery.cpp:1723: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000148f96f8 23. /build/src/Interpreters/InterpreterCreateQuery.cpp:2352: DB::InterpreterCreateQuery::execute() @ 0x0000000014905a41 24. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88dc9 25. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 26. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 27. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 28. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 29. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 30. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 31. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 2025.07.28 12:00:36.747552 [ 4900 ] {2dea0e53-67db-405c-9700-b5cdec0d741a} executeQuery: Code: 36. DB::Exception: The number of hash functions for bloom filter cannot be zero. (BAD_ARGUMENTS) (version 25.3.6.10636.altinitytest (altinity build)) (from [::1]:43270) (comment: 01384_bloom_filter_bad_arguments.sql) (query 5, line 6) (in query: CREATE TABLE test (`a` String, INDEX a a TYPE tokenbf_v1(1, 0, 1) GRANULARITY 1) ENGINE = MergeTree ORDER BY a SETTINGS index_granularity = 31235, 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 = 258222230, compact_parts_max_bytes_to_buffer = 472164226, compact_parts_max_granules_to_buffer = 119, compact_parts_merge_max_bytes_to_prefetch_part = 17681283, merge_max_block_size = 2282, old_parts_lifetime = 480., prefer_fetch_merged_part_size_threshold = 10737418240, vertical_merge_algorithm_min_rows_to_activate = 387269, vertical_merge_algorithm_min_columns_to_activate = 100, min_merge_bytes_to_use_direct_io = 10737418240, index_granularity_bytes = 16941609, use_const_adaptive_granularity = true, enable_index_granularity_compression = false, concurrent_part_removal_threshold = 91, 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 = 59202, primary_key_compress_block_size = 46175, 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. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000000a074fcb 4. /build/src/Interpreters/BloomFilter.cpp:30: DB::BloomFilterParameters::BloomFilterParameters(unsigned long, unsigned long, unsigned long) @ 0x00000000143f6728 5. /build/src/Storages/MergeTree/MergeTreeIndexBloomFilterText.cpp:814: DB::bloomFilterIndexTextValidator(DB::IndexDescription const&, bool) @ 0x0000000016442fea 6. /build/src/Storages/MergeTree/MergeTreeData.cpp:807: DB::MergeTreeData::checkProperties(DB::StorageInMemoryMetadata const&, DB::StorageInMemoryMetadata const&, bool, bool, bool, bool, std::shared_ptr) const @ 0x0000000016307fa2 7. /build/src/Storages/MergeTree/MergeTreeData.cpp:868: DB::MergeTreeData::setProperties(DB::StorageInMemoryMetadata const&, DB::StorageInMemoryMetadata const&, bool, std::shared_ptr) @ 0x000000001630257f 8. /build/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) @ 0x00000000163014fc 9. /build/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>) @ 0x0000000016632995 10. /build/contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: std::shared_ptr std::allocate_shared[abi:se190107], 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>&&) @ 0x00000000166326f0 11. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:851: DB::create(DB::StorageFactory::Arguments const&) @ 0x000000001662f01d 12. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000015d81ea2 13. /build/src/Interpreters/InterpreterCreateQuery.cpp:1945: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x00000000149009bb 14. /build/src/Interpreters/InterpreterCreateQuery.cpp:1743: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000148f9aa9 15. /build/src/Interpreters/InterpreterCreateQuery.cpp:2352: DB::InterpreterCreateQuery::execute() @ 0x0000000014905a41 16. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88dc9 17. /build/src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x0000000014c8ca7b 18. /build/src/Interpreters/DDLWorker.cpp:510: DB::DDLWorker::tryExecuteQuery(DB::DDLTaskBase&, std::shared_ptr const&, bool) @ 0x00000000144dab9e 19. /build/src/Interpreters/DDLWorker.cpp:675: DB::DDLWorker::processTask(DB::DDLTaskBase&, std::shared_ptr const&, bool) @ 0x00000000144d8ffe 20. /build/src/Databases/DatabaseReplicatedWorker.cpp:372: DB::DatabaseReplicatedDDLWorker::tryEnqueueAndExecuteEntry(DB::DDLLogEntry&, std::shared_ptr, bool) @ 0x0000000013dc29ab 21. /build/src/Databases/DatabaseReplicated.cpp:1139: DB::DatabaseReplicated::tryEnqueueReplicatedDDL(std::shared_ptr const&, std::shared_ptr, DB::QueryFlags) @ 0x0000000013d9f73c 22. /build/src/Interpreters/InterpreterCreateQuery.cpp:1723: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000148f96f8 23. /build/src/Interpreters/InterpreterCreateQuery.cpp:2352: DB::InterpreterCreateQuery::execute() @ 0x0000000014905a41 24. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88dc9 25. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 26. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 27. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 28. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 29. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 30. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 31. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 2025.07.28 12:00:36.755190 [ 4900 ] {} TCPHandler: Code: 36. DB::Exception: The number of hash functions for bloom filter cannot be zero. (BAD_ARGUMENTS), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000000a074fcb 4. /build/src/Interpreters/BloomFilter.cpp:30: DB::BloomFilterParameters::BloomFilterParameters(unsigned long, unsigned long, unsigned long) @ 0x00000000143f6728 5. /build/src/Storages/MergeTree/MergeTreeIndexBloomFilterText.cpp:814: DB::bloomFilterIndexTextValidator(DB::IndexDescription const&, bool) @ 0x0000000016442fea 6. /build/src/Storages/MergeTree/MergeTreeData.cpp:807: DB::MergeTreeData::checkProperties(DB::StorageInMemoryMetadata const&, DB::StorageInMemoryMetadata const&, bool, bool, bool, bool, std::shared_ptr) const @ 0x0000000016307fa2 7. /build/src/Storages/MergeTree/MergeTreeData.cpp:868: DB::MergeTreeData::setProperties(DB::StorageInMemoryMetadata const&, DB::StorageInMemoryMetadata const&, bool, std::shared_ptr) @ 0x000000001630257f 8. /build/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) @ 0x00000000163014fc 9. /build/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>) @ 0x0000000016632995 10. /build/contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: std::shared_ptr std::allocate_shared[abi:se190107], 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>&&) @ 0x00000000166326f0 11. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:851: DB::create(DB::StorageFactory::Arguments const&) @ 0x000000001662f01d 12. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000015d81ea2 13. /build/src/Interpreters/InterpreterCreateQuery.cpp:1945: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x00000000149009bb 14. /build/src/Interpreters/InterpreterCreateQuery.cpp:1743: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000148f9aa9 15. /build/src/Interpreters/InterpreterCreateQuery.cpp:2352: DB::InterpreterCreateQuery::execute() @ 0x0000000014905a41 16. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88dc9 17. /build/src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x0000000014c8ca7b 18. /build/src/Interpreters/DDLWorker.cpp:510: DB::DDLWorker::tryExecuteQuery(DB::DDLTaskBase&, std::shared_ptr const&, bool) @ 0x00000000144dab9e 19. /build/src/Interpreters/DDLWorker.cpp:675: DB::DDLWorker::processTask(DB::DDLTaskBase&, std::shared_ptr const&, bool) @ 0x00000000144d8ffe 20. /build/src/Databases/DatabaseReplicatedWorker.cpp:372: DB::DatabaseReplicatedDDLWorker::tryEnqueueAndExecuteEntry(DB::DDLLogEntry&, std::shared_ptr, bool) @ 0x0000000013dc29ab 21. /build/src/Databases/DatabaseReplicated.cpp:1139: DB::DatabaseReplicated::tryEnqueueReplicatedDDL(std::shared_ptr const&, std::shared_ptr, DB::QueryFlags) @ 0x0000000013d9f73c 22. /build/src/Interpreters/InterpreterCreateQuery.cpp:1723: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000148f96f8 23. /build/src/Interpreters/InterpreterCreateQuery.cpp:2352: DB::InterpreterCreateQuery::execute() @ 0x0000000014905a41 24. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88dc9 25. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 26. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 27. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 28. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 29. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 30. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 31. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 2025.07.28 12:00:37.065430 [ 3977 ] {} test_13.rmt2 (7f9b740d-015c-470e-8cc6-8ba33be0dc63): auto DB::StorageReplicatedMergeTree::processQueueEntry(ReplicatedMergeTreeQueue::SelectedEntryPtr)::(anonymous class)::operator()(LogEntryPtr &) const: Code: 86. DB::HTTPException: Received error from remote server http://146b4357c08d:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Ftest%2F01165%2Ftest_13%2Frmt%2Freplicas%2F1&part=20250728_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.6.10636.altinitytest (altinity build)) '. (RECEIVED_ERROR_FROM_REMOTE_IO_SERVER), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.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 const&, int&&, String const&, unsigned long&&, String const&) @ 0x000000000feda8d9 4. /build/src/IO/HTTPCommon.cpp:104: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x000000000feda6e2 5. /build/src/IO/HTTPCommon.cpp:93: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x000000000feda537 6. /build/src/IO/ReadWriteBufferFromHTTP.cpp:277: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x000000001184a4c4 7. /build/src/IO/ReadWriteBufferFromHTTP.cpp:285: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x000000001184a615 8. /build/src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x000000001184ae59 9. /build/src/IO/ReadWriteBufferFromHTTP.cpp:472: void std::__function::__policy_invoker::__call_impl[abi:se190107]>(std::__function::__policy_storage const*) @ 0x000000001184cedd 10. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001184858b 11. /build/src/IO/ReadWriteBufferFromHTTP.cpp:465: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x000000001184bf0b 12. /build/src/IO/ReadBuffer.h:60: DB::ReadBuffer::next() @ 0x000000000a148c7b 13. /build/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) @ 0x0000000011849fb2 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]>&)>&, 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&) @ 0x0000000011841980 15. /build/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) @ 0x000000001621208e 16. /build/src/Storages/StorageReplicatedMergeTree.cpp:5228: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl[abi:se190107] const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000015f9a5fe 17. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000015ed8bfd 18. /build/src/Storages/StorageReplicatedMergeTree.cpp:2514: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x0000000015ec9aab 19. /build/src/Storages/StorageReplicatedMergeTree.cpp:2349: DB::StorageReplicatedMergeTree::executeLogEntry(DB::ReplicatedMergeTreeLogEntry&) @ 0x0000000015eba91b 20. /build/src/Storages/StorageReplicatedMergeTree.cpp:3876: bool std::__function::__policy_invoker&)>::__call_impl[abi:se190107])::$_1, bool (std::shared_ptr&)>>(std::__function::__policy_storage const*, std::shared_ptr&) @ 0x0000000015f9837e 21. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000165d6fc3 22. /build/src/Storages/StorageReplicatedMergeTree.cpp:3872: DB::StorageReplicatedMergeTree::processQueueEntry(std::shared_ptr) @ 0x0000000015efc18a 23. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001624c1b2 24. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000162f9c70 25. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x00000000162fa55a 26. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc6653 27. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000000fccc4c3 28. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc3d92 29. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fcca080 30. ? @ 0x00007fbc6213eac3 31. ? @ 0x00007fbc621d0850 (version 25.3.6.10636.altinitytest (altinity build)) 2025.07.28 12:00:37.370008 [ 3969 ] {} test_13.rmt2 (7f9b740d-015c-470e-8cc6-8ba33be0dc63): auto DB::StorageReplicatedMergeTree::processQueueEntry(ReplicatedMergeTreeQueue::SelectedEntryPtr)::(anonymous class)::operator()(LogEntryPtr &) const: Code: 86. DB::HTTPException: Received error from remote server http://146b4357c08d:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Ftest%2F01165%2Ftest_13%2Frmt%2Freplicas%2F1&part=20250728_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.6.10636.altinitytest (altinity build)) '. (RECEIVED_ERROR_FROM_REMOTE_IO_SERVER), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.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 const&, int&&, String const&, unsigned long&&, String const&) @ 0x000000000feda8d9 4. /build/src/IO/HTTPCommon.cpp:104: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x000000000feda6e2 5. /build/src/IO/HTTPCommon.cpp:93: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x000000000feda537 6. /build/src/IO/ReadWriteBufferFromHTTP.cpp:277: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x000000001184a4c4 7. /build/src/IO/ReadWriteBufferFromHTTP.cpp:285: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x000000001184a615 8. /build/src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x000000001184ae59 9. /build/src/IO/ReadWriteBufferFromHTTP.cpp:472: void std::__function::__policy_invoker::__call_impl[abi:se190107]>(std::__function::__policy_storage const*) @ 0x000000001184cedd 10. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001184858b 11. /build/src/IO/ReadWriteBufferFromHTTP.cpp:465: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x000000001184bf0b 12. /build/src/IO/ReadBuffer.h:60: DB::ReadBuffer::next() @ 0x000000000a148c7b 13. /build/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) @ 0x0000000011849fb2 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]>&)>&, 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&) @ 0x0000000011841980 15. /build/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) @ 0x000000001621208e 16. /build/src/Storages/StorageReplicatedMergeTree.cpp:5228: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl[abi:se190107] const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000015f9a5fe 17. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000015ed8bfd 18. /build/src/Storages/StorageReplicatedMergeTree.cpp:2514: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x0000000015ec9aab 19. /build/src/Storages/StorageReplicatedMergeTree.cpp:2349: DB::StorageReplicatedMergeTree::executeLogEntry(DB::ReplicatedMergeTreeLogEntry&) @ 0x0000000015eba91b 20. /build/src/Storages/StorageReplicatedMergeTree.cpp:3876: bool std::__function::__policy_invoker&)>::__call_impl[abi:se190107])::$_1, bool (std::shared_ptr&)>>(std::__function::__policy_storage const*, std::shared_ptr&) @ 0x0000000015f9837e 21. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000165d6fc3 22. /build/src/Storages/StorageReplicatedMergeTree.cpp:3872: DB::StorageReplicatedMergeTree::processQueueEntry(std::shared_ptr) @ 0x0000000015efc18a 23. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001624c1b2 24. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000162f9c70 25. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x00000000162fa55a 26. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc6653 27. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000000fccc4c3 28. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc3d92 29. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fcca080 30. ? @ 0x00007fbc6213eac3 31. ? @ 0x00007fbc621d0850 (version 25.3.6.10636.altinitytest (altinity build)) 2025.07.28 12:00:37.410389 [ 4900 ] {e0eecfbf-c800-4c35-a49a-3aaf1d3f586c} executeQuery: Code: 36. DB::Exception: All parameters to *bf_v1 index must be unsigned integers. (BAD_ARGUMENTS) (version 25.3.6.10636.altinitytest (altinity build)) (from 0.0.0.0:0) (comment: 01384_bloom_filter_bad_arguments.sql) (in query: /* ddl_entry=query-0000000143 */ CREATE TABLE test_5.test UUID '8aa1f39c-1fd1-41cf-9e9a-bbceb4592735' (`a` String, INDEX a a TYPE tokenbf_v1(0.1, 2, 0) GRANULARITY 1) ENGINE = MergeTree ORDER BY a SETTINGS index_granularity = 31235, 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 = 258222230, compact_parts_max_bytes_to_buffer = 472164226, compact_parts_max_granules_to_buffer = 119, compact_parts_merge_max_bytes_to_prefetch_part = 17681283, merge_max_block_size = 2282, old_parts_lifetime = 480., prefer_fetch_merged_part_size_threshold = 10737418240, vertical_merge_algorithm_min_rows_to_activate = 387269, vertical_merge_algorithm_min_columns_to_activate = 100, min_merge_bytes_to_use_direct_io = 10737418240, index_granularity_bytes = 16941609, use_const_adaptive_granularity = true, enable_index_granularity_compression = false, concurrent_part_removal_threshold = 91, 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 = 59202, primary_key_compress_block_size = 46175, 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. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000000a074fcb 4. /build/src/Storages/MergeTree/MergeTreeIndexBloomFilterText.cpp:811: DB::bloomFilterIndexTextValidator(DB::IndexDescription const&, bool) @ 0x0000000016443095 5. /build/src/Storages/MergeTree/MergeTreeData.cpp:807: DB::MergeTreeData::checkProperties(DB::StorageInMemoryMetadata const&, DB::StorageInMemoryMetadata const&, bool, bool, bool, bool, std::shared_ptr) const @ 0x0000000016307fa2 6. /build/src/Storages/MergeTree/MergeTreeData.cpp:868: DB::MergeTreeData::setProperties(DB::StorageInMemoryMetadata const&, DB::StorageInMemoryMetadata const&, bool, std::shared_ptr) @ 0x000000001630257f 7. /build/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) @ 0x00000000163014fc 8. /build/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>) @ 0x0000000016632995 9. /build/contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: std::shared_ptr std::allocate_shared[abi:se190107], 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>&&) @ 0x00000000166326f0 10. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:851: DB::create(DB::StorageFactory::Arguments const&) @ 0x000000001662f01d 11. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000015d81ea2 12. /build/src/Interpreters/InterpreterCreateQuery.cpp:1945: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x00000000149009bb 13. /build/src/Interpreters/InterpreterCreateQuery.cpp:1743: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000148f9aa9 14. /build/src/Interpreters/InterpreterCreateQuery.cpp:2352: DB::InterpreterCreateQuery::execute() @ 0x0000000014905a41 15. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88dc9 16. /build/src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x0000000014c8ca7b 17. /build/src/Interpreters/DDLWorker.cpp:510: DB::DDLWorker::tryExecuteQuery(DB::DDLTaskBase&, std::shared_ptr const&, bool) @ 0x00000000144dab9e 18. /build/src/Interpreters/DDLWorker.cpp:675: DB::DDLWorker::processTask(DB::DDLTaskBase&, std::shared_ptr const&, bool) @ 0x00000000144d8ffe 19. /build/src/Databases/DatabaseReplicatedWorker.cpp:372: DB::DatabaseReplicatedDDLWorker::tryEnqueueAndExecuteEntry(DB::DDLLogEntry&, std::shared_ptr, bool) @ 0x0000000013dc29ab 20. /build/src/Databases/DatabaseReplicated.cpp:1139: DB::DatabaseReplicated::tryEnqueueReplicatedDDL(std::shared_ptr const&, std::shared_ptr, DB::QueryFlags) @ 0x0000000013d9f73c 21. /build/src/Interpreters/InterpreterCreateQuery.cpp:1723: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000148f96f8 22. /build/src/Interpreters/InterpreterCreateQuery.cpp:2352: DB::InterpreterCreateQuery::execute() @ 0x0000000014905a41 23. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88dc9 24. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 25. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 26. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 27. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 28. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 29. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 30. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 31. ? @ 0x00007fbc6213eac3 2025.07.28 12:00:37.451736 [ 4900 ] {e0eecfbf-c800-4c35-a49a-3aaf1d3f586c} executeQuery: Code: 36. DB::Exception: All parameters to *bf_v1 index must be unsigned integers. (BAD_ARGUMENTS) (version 25.3.6.10636.altinitytest (altinity build)) (from [::1]:43270) (comment: 01384_bloom_filter_bad_arguments.sql) (query 6, line 8) (in query: CREATE TABLE test (`a` String, INDEX a a TYPE tokenbf_v1(0.1, 2, 0) GRANULARITY 1) ENGINE = MergeTree ORDER BY a SETTINGS index_granularity = 31235, 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 = 258222230, compact_parts_max_bytes_to_buffer = 472164226, compact_parts_max_granules_to_buffer = 119, compact_parts_merge_max_bytes_to_prefetch_part = 17681283, merge_max_block_size = 2282, old_parts_lifetime = 480., prefer_fetch_merged_part_size_threshold = 10737418240, vertical_merge_algorithm_min_rows_to_activate = 387269, vertical_merge_algorithm_min_columns_to_activate = 100, min_merge_bytes_to_use_direct_io = 10737418240, index_granularity_bytes = 16941609, use_const_adaptive_granularity = true, enable_index_granularity_compression = false, concurrent_part_removal_threshold = 91, 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 = 59202, primary_key_compress_block_size = 46175, 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. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000000a074fcb 4. /build/src/Storages/MergeTree/MergeTreeIndexBloomFilterText.cpp:811: DB::bloomFilterIndexTextValidator(DB::IndexDescription const&, bool) @ 0x0000000016443095 5. /build/src/Storages/MergeTree/MergeTreeData.cpp:807: DB::MergeTreeData::checkProperties(DB::StorageInMemoryMetadata const&, DB::StorageInMemoryMetadata const&, bool, bool, bool, bool, std::shared_ptr) const @ 0x0000000016307fa2 6. /build/src/Storages/MergeTree/MergeTreeData.cpp:868: DB::MergeTreeData::setProperties(DB::StorageInMemoryMetadata const&, DB::StorageInMemoryMetadata const&, bool, std::shared_ptr) @ 0x000000001630257f 7. /build/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) @ 0x00000000163014fc 8. /build/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>) @ 0x0000000016632995 9. /build/contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: std::shared_ptr std::allocate_shared[abi:se190107], 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>&&) @ 0x00000000166326f0 10. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:851: DB::create(DB::StorageFactory::Arguments const&) @ 0x000000001662f01d 11. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000015d81ea2 12. /build/src/Interpreters/InterpreterCreateQuery.cpp:1945: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x00000000149009bb 13. /build/src/Interpreters/InterpreterCreateQuery.cpp:1743: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000148f9aa9 14. /build/src/Interpreters/InterpreterCreateQuery.cpp:2352: DB::InterpreterCreateQuery::execute() @ 0x0000000014905a41 15. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88dc9 16. /build/src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x0000000014c8ca7b 17. /build/src/Interpreters/DDLWorker.cpp:510: DB::DDLWorker::tryExecuteQuery(DB::DDLTaskBase&, std::shared_ptr const&, bool) @ 0x00000000144dab9e 18. /build/src/Interpreters/DDLWorker.cpp:675: DB::DDLWorker::processTask(DB::DDLTaskBase&, std::shared_ptr const&, bool) @ 0x00000000144d8ffe 19. /build/src/Databases/DatabaseReplicatedWorker.cpp:372: DB::DatabaseReplicatedDDLWorker::tryEnqueueAndExecuteEntry(DB::DDLLogEntry&, std::shared_ptr, bool) @ 0x0000000013dc29ab 20. /build/src/Databases/DatabaseReplicated.cpp:1139: DB::DatabaseReplicated::tryEnqueueReplicatedDDL(std::shared_ptr const&, std::shared_ptr, DB::QueryFlags) @ 0x0000000013d9f73c 21. /build/src/Interpreters/InterpreterCreateQuery.cpp:1723: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000148f96f8 22. /build/src/Interpreters/InterpreterCreateQuery.cpp:2352: DB::InterpreterCreateQuery::execute() @ 0x0000000014905a41 23. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88dc9 24. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 25. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 26. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 27. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 28. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 29. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 30. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 31. ? @ 0x00007fbc6213eac3 2025.07.28 12:00:37.454888 [ 4900 ] {} TCPHandler: Code: 36. DB::Exception: All parameters to *bf_v1 index must be unsigned integers. (BAD_ARGUMENTS), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000000a074fcb 4. /build/src/Storages/MergeTree/MergeTreeIndexBloomFilterText.cpp:811: DB::bloomFilterIndexTextValidator(DB::IndexDescription const&, bool) @ 0x0000000016443095 5. /build/src/Storages/MergeTree/MergeTreeData.cpp:807: DB::MergeTreeData::checkProperties(DB::StorageInMemoryMetadata const&, DB::StorageInMemoryMetadata const&, bool, bool, bool, bool, std::shared_ptr) const @ 0x0000000016307fa2 6. /build/src/Storages/MergeTree/MergeTreeData.cpp:868: DB::MergeTreeData::setProperties(DB::StorageInMemoryMetadata const&, DB::StorageInMemoryMetadata const&, bool, std::shared_ptr) @ 0x000000001630257f 7. /build/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) @ 0x00000000163014fc 8. /build/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>) @ 0x0000000016632995 9. /build/contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: std::shared_ptr std::allocate_shared[abi:se190107], 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>&&) @ 0x00000000166326f0 10. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:851: DB::create(DB::StorageFactory::Arguments const&) @ 0x000000001662f01d 11. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000015d81ea2 12. /build/src/Interpreters/InterpreterCreateQuery.cpp:1945: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x00000000149009bb 13. /build/src/Interpreters/InterpreterCreateQuery.cpp:1743: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000148f9aa9 14. /build/src/Interpreters/InterpreterCreateQuery.cpp:2352: DB::InterpreterCreateQuery::execute() @ 0x0000000014905a41 15. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88dc9 16. /build/src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x0000000014c8ca7b 17. /build/src/Interpreters/DDLWorker.cpp:510: DB::DDLWorker::tryExecuteQuery(DB::DDLTaskBase&, std::shared_ptr const&, bool) @ 0x00000000144dab9e 18. /build/src/Interpreters/DDLWorker.cpp:675: DB::DDLWorker::processTask(DB::DDLTaskBase&, std::shared_ptr const&, bool) @ 0x00000000144d8ffe 19. /build/src/Databases/DatabaseReplicatedWorker.cpp:372: DB::DatabaseReplicatedDDLWorker::tryEnqueueAndExecuteEntry(DB::DDLLogEntry&, std::shared_ptr, bool) @ 0x0000000013dc29ab 20. /build/src/Databases/DatabaseReplicated.cpp:1139: DB::DatabaseReplicated::tryEnqueueReplicatedDDL(std::shared_ptr const&, std::shared_ptr, DB::QueryFlags) @ 0x0000000013d9f73c 21. /build/src/Interpreters/InterpreterCreateQuery.cpp:1723: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000148f96f8 22. /build/src/Interpreters/InterpreterCreateQuery.cpp:2352: DB::InterpreterCreateQuery::execute() @ 0x0000000014905a41 23. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88dc9 24. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 25. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 26. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 27. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 28. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 29. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 30. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 31. ? @ 0x00007fbc6213eac3 2025.07.28 12:00:37.708435 [ 4900 ] {004ef28a-a886-4863-ac7b-ec2db2cbf732} executeQuery: Code: 36. DB::Exception: All parameters to *bf_v1 index must be unsigned integers. (BAD_ARGUMENTS) (version 25.3.6.10636.altinitytest (altinity build)) (from 0.0.0.0:0) (comment: 01384_bloom_filter_bad_arguments.sql) (in query: /* ddl_entry=query-0000000144 */ CREATE TABLE test_5.test UUID '2cec20d0-9635-4e7e-a0bc-a37bb2656197' (`a` String, INDEX a a TYPE tokenbf_v1(-1, 2, 0) GRANULARITY 1) ENGINE = MergeTree ORDER BY a SETTINGS index_granularity = 31235, 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 = 258222230, compact_parts_max_bytes_to_buffer = 472164226, compact_parts_max_granules_to_buffer = 119, compact_parts_merge_max_bytes_to_prefetch_part = 17681283, merge_max_block_size = 2282, old_parts_lifetime = 480., prefer_fetch_merged_part_size_threshold = 10737418240, vertical_merge_algorithm_min_rows_to_activate = 387269, vertical_merge_algorithm_min_columns_to_activate = 100, min_merge_bytes_to_use_direct_io = 10737418240, index_granularity_bytes = 16941609, use_const_adaptive_granularity = true, enable_index_granularity_compression = false, concurrent_part_removal_threshold = 91, 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 = 59202, primary_key_compress_block_size = 46175, 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. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000000a074fcb 4. /build/src/Storages/MergeTree/MergeTreeIndexBloomFilterText.cpp:811: DB::bloomFilterIndexTextValidator(DB::IndexDescription const&, bool) @ 0x0000000016443095 5. /build/src/Storages/MergeTree/MergeTreeData.cpp:807: DB::MergeTreeData::checkProperties(DB::StorageInMemoryMetadata const&, DB::StorageInMemoryMetadata const&, bool, bool, bool, bool, std::shared_ptr) const @ 0x0000000016307fa2 6. /build/src/Storages/MergeTree/MergeTreeData.cpp:868: DB::MergeTreeData::setProperties(DB::StorageInMemoryMetadata const&, DB::StorageInMemoryMetadata const&, bool, std::shared_ptr) @ 0x000000001630257f 7. /build/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) @ 0x00000000163014fc 8. /build/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>) @ 0x0000000016632995 9. /build/contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: std::shared_ptr std::allocate_shared[abi:se190107], 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>&&) @ 0x00000000166326f0 10. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:851: DB::create(DB::StorageFactory::Arguments const&) @ 0x000000001662f01d 11. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000015d81ea2 12. /build/src/Interpreters/InterpreterCreateQuery.cpp:1945: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x00000000149009bb 13. /build/src/Interpreters/InterpreterCreateQuery.cpp:1743: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000148f9aa9 14. /build/src/Interpreters/InterpreterCreateQuery.cpp:2352: DB::InterpreterCreateQuery::execute() @ 0x0000000014905a41 15. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88dc9 16. /build/src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x0000000014c8ca7b 17. /build/src/Interpreters/DDLWorker.cpp:510: DB::DDLWorker::tryExecuteQuery(DB::DDLTaskBase&, std::shared_ptr const&, bool) @ 0x00000000144dab9e 18. /build/src/Interpreters/DDLWorker.cpp:675: DB::DDLWorker::processTask(DB::DDLTaskBase&, std::shared_ptr const&, bool) @ 0x00000000144d8ffe 19. /build/src/Databases/DatabaseReplicatedWorker.cpp:372: DB::DatabaseReplicatedDDLWorker::tryEnqueueAndExecuteEntry(DB::DDLLogEntry&, std::shared_ptr, bool) @ 0x0000000013dc29ab 20. /build/src/Databases/DatabaseReplicated.cpp:1139: DB::DatabaseReplicated::tryEnqueueReplicatedDDL(std::shared_ptr const&, std::shared_ptr, DB::QueryFlags) @ 0x0000000013d9f73c 21. /build/src/Interpreters/InterpreterCreateQuery.cpp:1723: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000148f96f8 22. /build/src/Interpreters/InterpreterCreateQuery.cpp:2352: DB::InterpreterCreateQuery::execute() @ 0x0000000014905a41 23. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88dc9 24. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 25. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 26. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 27. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 28. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 29. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 30. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 31. ? @ 0x00007fbc6213eac3 2025.07.28 12:00:37.815122 [ 4900 ] {004ef28a-a886-4863-ac7b-ec2db2cbf732} executeQuery: Code: 36. DB::Exception: All parameters to *bf_v1 index must be unsigned integers. (BAD_ARGUMENTS) (version 25.3.6.10636.altinitytest (altinity build)) (from [::1]:43270) (comment: 01384_bloom_filter_bad_arguments.sql) (query 7, line 9) (in query: CREATE TABLE test (`a` String, INDEX a a TYPE tokenbf_v1(-1, 2, 0) GRANULARITY 1) ENGINE = MergeTree ORDER BY a SETTINGS index_granularity = 31235, 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 = 258222230, compact_parts_max_bytes_to_buffer = 472164226, compact_parts_max_granules_to_buffer = 119, compact_parts_merge_max_bytes_to_prefetch_part = 17681283, merge_max_block_size = 2282, old_parts_lifetime = 480., prefer_fetch_merged_part_size_threshold = 10737418240, vertical_merge_algorithm_min_rows_to_activate = 387269, vertical_merge_algorithm_min_columns_to_activate = 100, min_merge_bytes_to_use_direct_io = 10737418240, index_granularity_bytes = 16941609, use_const_adaptive_granularity = true, enable_index_granularity_compression = false, concurrent_part_removal_threshold = 91, 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 = 59202, primary_key_compress_block_size = 46175, 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. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000000a074fcb 4. /build/src/Storages/MergeTree/MergeTreeIndexBloomFilterText.cpp:811: DB::bloomFilterIndexTextValidator(DB::IndexDescription const&, bool) @ 0x0000000016443095 5. /build/src/Storages/MergeTree/MergeTreeData.cpp:807: DB::MergeTreeData::checkProperties(DB::StorageInMemoryMetadata const&, DB::StorageInMemoryMetadata const&, bool, bool, bool, bool, std::shared_ptr) const @ 0x0000000016307fa2 6. /build/src/Storages/MergeTree/MergeTreeData.cpp:868: DB::MergeTreeData::setProperties(DB::StorageInMemoryMetadata const&, DB::StorageInMemoryMetadata const&, bool, std::shared_ptr) @ 0x000000001630257f 7. /build/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) @ 0x00000000163014fc 8. /build/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>) @ 0x0000000016632995 9. /build/contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: std::shared_ptr std::allocate_shared[abi:se190107], 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>&&) @ 0x00000000166326f0 10. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:851: DB::create(DB::StorageFactory::Arguments const&) @ 0x000000001662f01d 11. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000015d81ea2 12. /build/src/Interpreters/InterpreterCreateQuery.cpp:1945: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x00000000149009bb 13. /build/src/Interpreters/InterpreterCreateQuery.cpp:1743: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000148f9aa9 14. /build/src/Interpreters/InterpreterCreateQuery.cpp:2352: DB::InterpreterCreateQuery::execute() @ 0x0000000014905a41 15. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88dc9 16. /build/src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x0000000014c8ca7b 17. /build/src/Interpreters/DDLWorker.cpp:510: DB::DDLWorker::tryExecuteQuery(DB::DDLTaskBase&, std::shared_ptr const&, bool) @ 0x00000000144dab9e 18. /build/src/Interpreters/DDLWorker.cpp:675: DB::DDLWorker::processTask(DB::DDLTaskBase&, std::shared_ptr const&, bool) @ 0x00000000144d8ffe 19. /build/src/Databases/DatabaseReplicatedWorker.cpp:372: DB::DatabaseReplicatedDDLWorker::tryEnqueueAndExecuteEntry(DB::DDLLogEntry&, std::shared_ptr, bool) @ 0x0000000013dc29ab 20. /build/src/Databases/DatabaseReplicated.cpp:1139: DB::DatabaseReplicated::tryEnqueueReplicatedDDL(std::shared_ptr const&, std::shared_ptr, DB::QueryFlags) @ 0x0000000013d9f73c 21. /build/src/Interpreters/InterpreterCreateQuery.cpp:1723: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000148f96f8 22. /build/src/Interpreters/InterpreterCreateQuery.cpp:2352: DB::InterpreterCreateQuery::execute() @ 0x0000000014905a41 23. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88dc9 24. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 25. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 26. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 27. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 28. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 29. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 30. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 31. ? @ 0x00007fbc6213eac3 2025.07.28 12:00:37.819526 [ 4900 ] {} TCPHandler: Code: 36. DB::Exception: All parameters to *bf_v1 index must be unsigned integers. (BAD_ARGUMENTS), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000000a074fcb 4. /build/src/Storages/MergeTree/MergeTreeIndexBloomFilterText.cpp:811: DB::bloomFilterIndexTextValidator(DB::IndexDescription const&, bool) @ 0x0000000016443095 5. /build/src/Storages/MergeTree/MergeTreeData.cpp:807: DB::MergeTreeData::checkProperties(DB::StorageInMemoryMetadata const&, DB::StorageInMemoryMetadata const&, bool, bool, bool, bool, std::shared_ptr) const @ 0x0000000016307fa2 6. /build/src/Storages/MergeTree/MergeTreeData.cpp:868: DB::MergeTreeData::setProperties(DB::StorageInMemoryMetadata const&, DB::StorageInMemoryMetadata const&, bool, std::shared_ptr) @ 0x000000001630257f 7. /build/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) @ 0x00000000163014fc 8. /build/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>) @ 0x0000000016632995 9. /build/contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: std::shared_ptr std::allocate_shared[abi:se190107], 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>&&) @ 0x00000000166326f0 10. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:851: DB::create(DB::StorageFactory::Arguments const&) @ 0x000000001662f01d 11. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000015d81ea2 12. /build/src/Interpreters/InterpreterCreateQuery.cpp:1945: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x00000000149009bb 13. /build/src/Interpreters/InterpreterCreateQuery.cpp:1743: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000148f9aa9 14. /build/src/Interpreters/InterpreterCreateQuery.cpp:2352: DB::InterpreterCreateQuery::execute() @ 0x0000000014905a41 15. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88dc9 16. /build/src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x0000000014c8ca7b 17. /build/src/Interpreters/DDLWorker.cpp:510: DB::DDLWorker::tryExecuteQuery(DB::DDLTaskBase&, std::shared_ptr const&, bool) @ 0x00000000144dab9e 18. /build/src/Interpreters/DDLWorker.cpp:675: DB::DDLWorker::processTask(DB::DDLTaskBase&, std::shared_ptr const&, bool) @ 0x00000000144d8ffe 19. /build/src/Databases/DatabaseReplicatedWorker.cpp:372: DB::DatabaseReplicatedDDLWorker::tryEnqueueAndExecuteEntry(DB::DDLLogEntry&, std::shared_ptr, bool) @ 0x0000000013dc29ab 20. /build/src/Databases/DatabaseReplicated.cpp:1139: DB::DatabaseReplicated::tryEnqueueReplicatedDDL(std::shared_ptr const&, std::shared_ptr, DB::QueryFlags) @ 0x0000000013d9f73c 21. /build/src/Interpreters/InterpreterCreateQuery.cpp:1723: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000148f96f8 22. /build/src/Interpreters/InterpreterCreateQuery.cpp:2352: DB::InterpreterCreateQuery::execute() @ 0x0000000014905a41 23. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88dc9 24. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 25. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 26. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 27. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 28. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 29. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 30. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 31. ? @ 0x00007fbc6213eac3 2025.07.28 12:00:37.840130 [ 3971 ] {} test_13.rmt2 (7f9b740d-015c-470e-8cc6-8ba33be0dc63): auto DB::StorageReplicatedMergeTree::processQueueEntry(ReplicatedMergeTreeQueue::SelectedEntryPtr)::(anonymous class)::operator()(LogEntryPtr &) const: Code: 86. DB::HTTPException: Received error from remote server http://146b4357c08d:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Ftest%2F01165%2Ftest_13%2Frmt%2Freplicas%2F1&part=20250728_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.6.10636.altinitytest (altinity build)) '. (RECEIVED_ERROR_FROM_REMOTE_IO_SERVER), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.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 const&, int&&, String const&, unsigned long&&, String const&) @ 0x000000000feda8d9 4. /build/src/IO/HTTPCommon.cpp:104: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x000000000feda6e2 5. /build/src/IO/HTTPCommon.cpp:93: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x000000000feda537 6. /build/src/IO/ReadWriteBufferFromHTTP.cpp:277: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x000000001184a4c4 7. /build/src/IO/ReadWriteBufferFromHTTP.cpp:285: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x000000001184a615 8. /build/src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x000000001184ae59 9. /build/src/IO/ReadWriteBufferFromHTTP.cpp:472: void std::__function::__policy_invoker::__call_impl[abi:se190107]>(std::__function::__policy_storage const*) @ 0x000000001184cedd 10. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001184858b 11. /build/src/IO/ReadWriteBufferFromHTTP.cpp:465: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x000000001184bf0b 12. /build/src/IO/ReadBuffer.h:60: DB::ReadBuffer::next() @ 0x000000000a148c7b 13. /build/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) @ 0x0000000011849fb2 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]>&)>&, 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&) @ 0x0000000011841980 15. /build/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) @ 0x000000001621208e 16. /build/src/Storages/StorageReplicatedMergeTree.cpp:5228: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl[abi:se190107] const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000015f9a5fe 17. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000015ed8bfd 18. /build/src/Storages/StorageReplicatedMergeTree.cpp:2514: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x0000000015ec9aab 19. /build/src/Storages/StorageReplicatedMergeTree.cpp:2349: DB::StorageReplicatedMergeTree::executeLogEntry(DB::ReplicatedMergeTreeLogEntry&) @ 0x0000000015eba91b 20. /build/src/Storages/StorageReplicatedMergeTree.cpp:3876: bool std::__function::__policy_invoker&)>::__call_impl[abi:se190107])::$_1, bool (std::shared_ptr&)>>(std::__function::__policy_storage const*, std::shared_ptr&) @ 0x0000000015f9837e 21. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000165d6fc3 22. /build/src/Storages/StorageReplicatedMergeTree.cpp:3872: DB::StorageReplicatedMergeTree::processQueueEntry(std::shared_ptr) @ 0x0000000015efc18a 23. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001624c1b2 24. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000162f9c70 25. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x00000000162fa55a 26. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc6653 27. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000000fccc4c3 28. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc3d92 29. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fcca080 30. ? @ 0x00007fbc6213eac3 31. ? @ 0x00007fbc621d0850 (version 25.3.6.10636.altinitytest (altinity build)) 2025.07.28 12:00:38.015885 [ 3974 ] {} test_13.rmt2 (7f9b740d-015c-470e-8cc6-8ba33be0dc63): auto DB::StorageReplicatedMergeTree::processQueueEntry(ReplicatedMergeTreeQueue::SelectedEntryPtr)::(anonymous class)::operator()(LogEntryPtr &) const: Code: 86. DB::HTTPException: Received error from remote server http://146b4357c08d:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Ftest%2F01165%2Ftest_13%2Frmt%2Freplicas%2F1&part=20250728_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.6.10636.altinitytest (altinity build)) '. (RECEIVED_ERROR_FROM_REMOTE_IO_SERVER), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.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 const&, int&&, String const&, unsigned long&&, String const&) @ 0x000000000feda8d9 4. /build/src/IO/HTTPCommon.cpp:104: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x000000000feda6e2 5. /build/src/IO/HTTPCommon.cpp:93: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x000000000feda537 6. /build/src/IO/ReadWriteBufferFromHTTP.cpp:277: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x000000001184a4c4 7. /build/src/IO/ReadWriteBufferFromHTTP.cpp:285: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x000000001184a615 8. /build/src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x000000001184ae59 9. /build/src/IO/ReadWriteBufferFromHTTP.cpp:472: void std::__function::__policy_invoker::__call_impl[abi:se190107]>(std::__function::__policy_storage const*) @ 0x000000001184cedd 10. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001184858b 11. /build/src/IO/ReadWriteBufferFromHTTP.cpp:465: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x000000001184bf0b 12. /build/src/IO/ReadBuffer.h:60: DB::ReadBuffer::next() @ 0x000000000a148c7b 13. /build/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) @ 0x0000000011849fb2 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]>&)>&, 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&) @ 0x0000000011841980 15. /build/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) @ 0x000000001621208e 16. /build/src/Storages/StorageReplicatedMergeTree.cpp:5228: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl[abi:se190107] const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000015f9a5fe 17. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000015ed8bfd 18. /build/src/Storages/StorageReplicatedMergeTree.cpp:2514: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x0000000015ec9aab 19. /build/src/Storages/StorageReplicatedMergeTree.cpp:2349: DB::StorageReplicatedMergeTree::executeLogEntry(DB::ReplicatedMergeTreeLogEntry&) @ 0x0000000015eba91b 20. /build/src/Storages/StorageReplicatedMergeTree.cpp:3876: bool std::__function::__policy_invoker&)>::__call_impl[abi:se190107])::$_1, bool (std::shared_ptr&)>>(std::__function::__policy_storage const*, std::shared_ptr&) @ 0x0000000015f9837e 21. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000165d6fc3 22. /build/src/Storages/StorageReplicatedMergeTree.cpp:3872: DB::StorageReplicatedMergeTree::processQueueEntry(std::shared_ptr) @ 0x0000000015efc18a 23. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001624c1b2 24. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000162f9c70 25. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x00000000162fa55a 26. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc6653 27. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000000fccc4c3 28. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc3d92 29. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fcca080 30. ? @ 0x00007fbc6213eac3 31. ? @ 0x00007fbc621d0850 (version 25.3.6.10636.altinitytest (altinity build)) 2025.07.28 12:00:38.338674 [ 5112 ] {0530ba94-e0e7-4f42-a08f-fc96c044043b} executeQuery: Code: 48. DB::Exception: Truncate is not supported by storage Merge. (NOT_IMPLEMENTED) (version 25.3.6.10636.altinitytest (altinity build)) (from [::1]:57276) (comment: 03217_filtering_in_storage_merge.sql) (in query: DROP DATABASE IF EXISTS test_ezfyv6yq SYNC ), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x000000000a06b56b 4. /build/src/Storages/IStorage.cpp:171: DB::IStorage::truncate(std::shared_ptr const&, std::shared_ptr const&, std::shared_ptr, DB::TableExclusiveLockHolder&) @ 0x0000000015d1ec7a 5. /build/src/Interpreters/InterpreterDropQuery.cpp:282: DB::InterpreterDropQuery::executeToTableImpl(std::shared_ptr const&, DB::ASTDropQuery&, std::shared_ptr&, StrongTypedef, DB::UUIDTag>&) @ 0x0000000014915304 6. /build/src/Interpreters/InterpreterDropQuery.cpp:461: DB::InterpreterDropQuery::executeToDatabaseImpl(DB::ASTDropQuery const&, std::shared_ptr&, std::vector, DB::UUIDTag>, std::allocator, DB::UUIDTag>>>&) @ 0x0000000014917707 7. /build/src/Interpreters/InterpreterDropQuery.cpp:363: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x0000000014913988 8. /build/src/Interpreters/InterpreterDropQuery.cpp:99: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000014913142 9. /build/src/Interpreters/InterpreterDropQuery.cpp:72: DB::InterpreterDropQuery::execute() @ 0x0000000014912b65 10. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88dc9 11. /build/src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x0000000014c8ca7b 12. /build/src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000001686da12 13. /build/src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x0000000016870807 14. /build/src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x0000000016907e99 15. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 16. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 17. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 18. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 19. ? @ 0x00007fbc6213eac3 20. ? @ 0x00007fbc621d0850 2025.07.28 12:00:38.352487 [ 5112 ] {0530ba94-e0e7-4f42-a08f-fc96c044043b} DynamicQueryHandler: 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. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x000000000a06b56b 4. /build/src/Storages/IStorage.cpp:171: DB::IStorage::truncate(std::shared_ptr const&, std::shared_ptr const&, std::shared_ptr, DB::TableExclusiveLockHolder&) @ 0x0000000015d1ec7a 5. /build/src/Interpreters/InterpreterDropQuery.cpp:282: DB::InterpreterDropQuery::executeToTableImpl(std::shared_ptr const&, DB::ASTDropQuery&, std::shared_ptr&, StrongTypedef, DB::UUIDTag>&) @ 0x0000000014915304 6. /build/src/Interpreters/InterpreterDropQuery.cpp:461: DB::InterpreterDropQuery::executeToDatabaseImpl(DB::ASTDropQuery const&, std::shared_ptr&, std::vector, DB::UUIDTag>, std::allocator, DB::UUIDTag>>>&) @ 0x0000000014917707 7. /build/src/Interpreters/InterpreterDropQuery.cpp:363: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x0000000014913988 8. /build/src/Interpreters/InterpreterDropQuery.cpp:99: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000014913142 9. /build/src/Interpreters/InterpreterDropQuery.cpp:72: DB::InterpreterDropQuery::execute() @ 0x0000000014912b65 10. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88dc9 11. /build/src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x0000000014c8ca7b 12. /build/src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000001686da12 13. /build/src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x0000000016870807 14. /build/src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x0000000016907e99 15. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 16. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 17. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 18. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 19. ? @ 0x00007fbc6213eac3 20. ? @ 0x00007fbc621d0850 (version 25.3.6.10636.altinitytest (altinity build)) 2025.07.28 12:00:38.499513 [ 4900 ] {fa272e46-9746-476f-89f8-7637b7abe6f8} executeQuery: Code: 36. DB::Exception: The size of bloom filter cannot be more than 1073741824. (BAD_ARGUMENTS) (version 25.3.6.10636.altinitytest (altinity build)) (from 0.0.0.0:0) (comment: 01384_bloom_filter_bad_arguments.sql) (in query: /* ddl_entry=query-0000000145 */ CREATE TABLE test_5.test UUID '9766a8d4-8fe2-4aa0-b4ae-13471dcbf14d' (`a` String, INDEX a a TYPE tokenbf_v1(4294967295, 2, 0) GRANULARITY 1) ENGINE = MergeTree ORDER BY a SETTINGS index_granularity = 31235, 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 = 258222230, compact_parts_max_bytes_to_buffer = 472164226, compact_parts_max_granules_to_buffer = 119, compact_parts_merge_max_bytes_to_prefetch_part = 17681283, merge_max_block_size = 2282, old_parts_lifetime = 480., prefer_fetch_merged_part_size_threshold = 10737418240, vertical_merge_algorithm_min_rows_to_activate = 387269, vertical_merge_algorithm_min_columns_to_activate = 100, min_merge_bytes_to_use_direct_io = 10737418240, index_granularity_bytes = 16941609, use_const_adaptive_granularity = true, enable_index_granularity_compression = false, concurrent_part_removal_threshold = 91, 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 = 59202, primary_key_compress_block_size = 46175, 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. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type>, unsigned long const&) @ 0x000000000a951dcb 4. /build/src/Interpreters/BloomFilter.cpp:32: DB::BloomFilterParameters::BloomFilterParameters(unsigned long, unsigned long, unsigned long) @ 0x00000000143f6785 5. /build/src/Storages/MergeTree/MergeTreeIndexBloomFilterText.cpp:814: DB::bloomFilterIndexTextValidator(DB::IndexDescription const&, bool) @ 0x0000000016442fea 6. /build/src/Storages/MergeTree/MergeTreeData.cpp:807: DB::MergeTreeData::checkProperties(DB::StorageInMemoryMetadata const&, DB::StorageInMemoryMetadata const&, bool, bool, bool, bool, std::shared_ptr) const @ 0x0000000016307fa2 7. /build/src/Storages/MergeTree/MergeTreeData.cpp:868: DB::MergeTreeData::setProperties(DB::StorageInMemoryMetadata const&, DB::StorageInMemoryMetadata const&, bool, std::shared_ptr) @ 0x000000001630257f 8. /build/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) @ 0x00000000163014fc 9. /build/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>) @ 0x0000000016632995 10. /build/contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: std::shared_ptr std::allocate_shared[abi:se190107], 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>&&) @ 0x00000000166326f0 11. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:851: DB::create(DB::StorageFactory::Arguments const&) @ 0x000000001662f01d 12. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000015d81ea2 13. /build/src/Interpreters/InterpreterCreateQuery.cpp:1945: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x00000000149009bb 14. /build/src/Interpreters/InterpreterCreateQuery.cpp:1743: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000148f9aa9 15. /build/src/Interpreters/InterpreterCreateQuery.cpp:2352: DB::InterpreterCreateQuery::execute() @ 0x0000000014905a41 16. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88dc9 17. /build/src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x0000000014c8ca7b 18. /build/src/Interpreters/DDLWorker.cpp:510: DB::DDLWorker::tryExecuteQuery(DB::DDLTaskBase&, std::shared_ptr const&, bool) @ 0x00000000144dab9e 19. /build/src/Interpreters/DDLWorker.cpp:675: DB::DDLWorker::processTask(DB::DDLTaskBase&, std::shared_ptr const&, bool) @ 0x00000000144d8ffe 20. /build/src/Databases/DatabaseReplicatedWorker.cpp:372: DB::DatabaseReplicatedDDLWorker::tryEnqueueAndExecuteEntry(DB::DDLLogEntry&, std::shared_ptr, bool) @ 0x0000000013dc29ab 21. /build/src/Databases/DatabaseReplicated.cpp:1139: DB::DatabaseReplicated::tryEnqueueReplicatedDDL(std::shared_ptr const&, std::shared_ptr, DB::QueryFlags) @ 0x0000000013d9f73c 22. /build/src/Interpreters/InterpreterCreateQuery.cpp:1723: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000148f96f8 23. /build/src/Interpreters/InterpreterCreateQuery.cpp:2352: DB::InterpreterCreateQuery::execute() @ 0x0000000014905a41 24. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88dc9 25. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 26. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 27. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 28. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 29. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 30. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 31. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 2025.07.28 12:00:38.547543 [ 4900 ] {fa272e46-9746-476f-89f8-7637b7abe6f8} executeQuery: Code: 36. DB::Exception: The size of bloom filter cannot be more than 1073741824. (BAD_ARGUMENTS) (version 25.3.6.10636.altinitytest (altinity build)) (from [::1]:43270) (comment: 01384_bloom_filter_bad_arguments.sql) (query 8, line 10) (in query: CREATE TABLE test (`a` String, INDEX a a TYPE tokenbf_v1(4294967295, 2, 0) GRANULARITY 1) ENGINE = MergeTree ORDER BY a SETTINGS index_granularity = 31235, 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 = 258222230, compact_parts_max_bytes_to_buffer = 472164226, compact_parts_max_granules_to_buffer = 119, compact_parts_merge_max_bytes_to_prefetch_part = 17681283, merge_max_block_size = 2282, old_parts_lifetime = 480., prefer_fetch_merged_part_size_threshold = 10737418240, vertical_merge_algorithm_min_rows_to_activate = 387269, vertical_merge_algorithm_min_columns_to_activate = 100, min_merge_bytes_to_use_direct_io = 10737418240, index_granularity_bytes = 16941609, use_const_adaptive_granularity = true, enable_index_granularity_compression = false, concurrent_part_removal_threshold = 91, 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 = 59202, primary_key_compress_block_size = 46175, 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. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type>, unsigned long const&) @ 0x000000000a951dcb 4. /build/src/Interpreters/BloomFilter.cpp:32: DB::BloomFilterParameters::BloomFilterParameters(unsigned long, unsigned long, unsigned long) @ 0x00000000143f6785 5. /build/src/Storages/MergeTree/MergeTreeIndexBloomFilterText.cpp:814: DB::bloomFilterIndexTextValidator(DB::IndexDescription const&, bool) @ 0x0000000016442fea 6. /build/src/Storages/MergeTree/MergeTreeData.cpp:807: DB::MergeTreeData::checkProperties(DB::StorageInMemoryMetadata const&, DB::StorageInMemoryMetadata const&, bool, bool, bool, bool, std::shared_ptr) const @ 0x0000000016307fa2 7. /build/src/Storages/MergeTree/MergeTreeData.cpp:868: DB::MergeTreeData::setProperties(DB::StorageInMemoryMetadata const&, DB::StorageInMemoryMetadata const&, bool, std::shared_ptr) @ 0x000000001630257f 8. /build/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) @ 0x00000000163014fc 9. /build/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>) @ 0x0000000016632995 10. /build/contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: std::shared_ptr std::allocate_shared[abi:se190107], 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>&&) @ 0x00000000166326f0 11. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:851: DB::create(DB::StorageFactory::Arguments const&) @ 0x000000001662f01d 12. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000015d81ea2 13. /build/src/Interpreters/InterpreterCreateQuery.cpp:1945: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x00000000149009bb 14. /build/src/Interpreters/InterpreterCreateQuery.cpp:1743: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000148f9aa9 15. /build/src/Interpreters/InterpreterCreateQuery.cpp:2352: DB::InterpreterCreateQuery::execute() @ 0x0000000014905a41 16. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88dc9 17. /build/src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x0000000014c8ca7b 18. /build/src/Interpreters/DDLWorker.cpp:510: DB::DDLWorker::tryExecuteQuery(DB::DDLTaskBase&, std::shared_ptr const&, bool) @ 0x00000000144dab9e 19. /build/src/Interpreters/DDLWorker.cpp:675: DB::DDLWorker::processTask(DB::DDLTaskBase&, std::shared_ptr const&, bool) @ 0x00000000144d8ffe 20. /build/src/Databases/DatabaseReplicatedWorker.cpp:372: DB::DatabaseReplicatedDDLWorker::tryEnqueueAndExecuteEntry(DB::DDLLogEntry&, std::shared_ptr, bool) @ 0x0000000013dc29ab 21. /build/src/Databases/DatabaseReplicated.cpp:1139: DB::DatabaseReplicated::tryEnqueueReplicatedDDL(std::shared_ptr const&, std::shared_ptr, DB::QueryFlags) @ 0x0000000013d9f73c 22. /build/src/Interpreters/InterpreterCreateQuery.cpp:1723: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000148f96f8 23. /build/src/Interpreters/InterpreterCreateQuery.cpp:2352: DB::InterpreterCreateQuery::execute() @ 0x0000000014905a41 24. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88dc9 25. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 26. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 27. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 28. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 29. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 30. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 31. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 2025.07.28 12:00:38.551848 [ 4900 ] {} TCPHandler: Code: 36. DB::Exception: The size of bloom filter cannot be more than 1073741824. (BAD_ARGUMENTS), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type>, unsigned long const&) @ 0x000000000a951dcb 4. /build/src/Interpreters/BloomFilter.cpp:32: DB::BloomFilterParameters::BloomFilterParameters(unsigned long, unsigned long, unsigned long) @ 0x00000000143f6785 5. /build/src/Storages/MergeTree/MergeTreeIndexBloomFilterText.cpp:814: DB::bloomFilterIndexTextValidator(DB::IndexDescription const&, bool) @ 0x0000000016442fea 6. /build/src/Storages/MergeTree/MergeTreeData.cpp:807: DB::MergeTreeData::checkProperties(DB::StorageInMemoryMetadata const&, DB::StorageInMemoryMetadata const&, bool, bool, bool, bool, std::shared_ptr) const @ 0x0000000016307fa2 7. /build/src/Storages/MergeTree/MergeTreeData.cpp:868: DB::MergeTreeData::setProperties(DB::StorageInMemoryMetadata const&, DB::StorageInMemoryMetadata const&, bool, std::shared_ptr) @ 0x000000001630257f 8. /build/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) @ 0x00000000163014fc 9. /build/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>) @ 0x0000000016632995 10. /build/contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: std::shared_ptr std::allocate_shared[abi:se190107], 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>&&) @ 0x00000000166326f0 11. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:851: DB::create(DB::StorageFactory::Arguments const&) @ 0x000000001662f01d 12. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000015d81ea2 13. /build/src/Interpreters/InterpreterCreateQuery.cpp:1945: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x00000000149009bb 14. /build/src/Interpreters/InterpreterCreateQuery.cpp:1743: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000148f9aa9 15. /build/src/Interpreters/InterpreterCreateQuery.cpp:2352: DB::InterpreterCreateQuery::execute() @ 0x0000000014905a41 16. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88dc9 17. /build/src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x0000000014c8ca7b 18. /build/src/Interpreters/DDLWorker.cpp:510: DB::DDLWorker::tryExecuteQuery(DB::DDLTaskBase&, std::shared_ptr const&, bool) @ 0x00000000144dab9e 19. /build/src/Interpreters/DDLWorker.cpp:675: DB::DDLWorker::processTask(DB::DDLTaskBase&, std::shared_ptr const&, bool) @ 0x00000000144d8ffe 20. /build/src/Databases/DatabaseReplicatedWorker.cpp:372: DB::DatabaseReplicatedDDLWorker::tryEnqueueAndExecuteEntry(DB::DDLLogEntry&, std::shared_ptr, bool) @ 0x0000000013dc29ab 21. /build/src/Databases/DatabaseReplicated.cpp:1139: DB::DatabaseReplicated::tryEnqueueReplicatedDDL(std::shared_ptr const&, std::shared_ptr, DB::QueryFlags) @ 0x0000000013d9f73c 22. /build/src/Interpreters/InterpreterCreateQuery.cpp:1723: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000148f96f8 23. /build/src/Interpreters/InterpreterCreateQuery.cpp:2352: DB::InterpreterCreateQuery::execute() @ 0x0000000014905a41 24. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88dc9 25. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 26. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 27. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 28. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 29. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 30. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 31. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 2025.07.28 12:00:38.726352 [ 3967 ] {} test_13.rmt2 (7f9b740d-015c-470e-8cc6-8ba33be0dc63): auto DB::StorageReplicatedMergeTree::processQueueEntry(ReplicatedMergeTreeQueue::SelectedEntryPtr)::(anonymous class)::operator()(LogEntryPtr &) const: Code: 86. DB::HTTPException: Received error from remote server http://146b4357c08d:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Ftest%2F01165%2Ftest_13%2Frmt%2Freplicas%2F1&part=20250728_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.6.10636.altinitytest (altinity build)) '. (RECEIVED_ERROR_FROM_REMOTE_IO_SERVER), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.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 const&, int&&, String const&, unsigned long&&, String const&) @ 0x000000000feda8d9 4. /build/src/IO/HTTPCommon.cpp:104: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x000000000feda6e2 5. /build/src/IO/HTTPCommon.cpp:93: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x000000000feda537 6. /build/src/IO/ReadWriteBufferFromHTTP.cpp:277: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x000000001184a4c4 7. /build/src/IO/ReadWriteBufferFromHTTP.cpp:285: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x000000001184a615 8. /build/src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x000000001184ae59 9. /build/src/IO/ReadWriteBufferFromHTTP.cpp:472: void std::__function::__policy_invoker::__call_impl[abi:se190107]>(std::__function::__policy_storage const*) @ 0x000000001184cedd 10. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001184858b 11. /build/src/IO/ReadWriteBufferFromHTTP.cpp:465: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x000000001184bf0b 12. /build/src/IO/ReadBuffer.h:60: DB::ReadBuffer::next() @ 0x000000000a148c7b 13. /build/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) @ 0x0000000011849fb2 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]>&)>&, 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&) @ 0x0000000011841980 15. /build/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) @ 0x000000001621208e 16. /build/src/Storages/StorageReplicatedMergeTree.cpp:5228: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl[abi:se190107] const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000015f9a5fe 17. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000015ed8bfd 18. /build/src/Storages/StorageReplicatedMergeTree.cpp:2514: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x0000000015ec9aab 19. /build/src/Storages/StorageReplicatedMergeTree.cpp:2349: DB::StorageReplicatedMergeTree::executeLogEntry(DB::ReplicatedMergeTreeLogEntry&) @ 0x0000000015eba91b 20. /build/src/Storages/StorageReplicatedMergeTree.cpp:3876: bool std::__function::__policy_invoker&)>::__call_impl[abi:se190107])::$_1, bool (std::shared_ptr&)>>(std::__function::__policy_storage const*, std::shared_ptr&) @ 0x0000000015f9837e 21. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000165d6fc3 22. /build/src/Storages/StorageReplicatedMergeTree.cpp:3872: DB::StorageReplicatedMergeTree::processQueueEntry(std::shared_ptr) @ 0x0000000015efc18a 23. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001624c1b2 24. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000162f9c70 25. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x00000000162fa55a 26. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc6653 27. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000000fccc4c3 28. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc3d92 29. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fcca080 30. ? @ 0x00007fbc6213eac3 31. ? @ 0x00007fbc621d0850 (version 25.3.6.10636.altinitytest (altinity build)) 2025.07.28 12:00:39.276049 [ 17255 ] {acfae459-df39-47eb-a321-858a4b397a4c} executeQuery: Code: 42. DB::Exception: Number of arguments for function locate doesn't match: passed 0, should be 2 or 3: In scope SELECT locate(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.6.10636.altinitytest (altinity build)) (from [::1]:43410) (comment: 00765_locate.sql) (query 3, line 4) (in query: SELECT locate();), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, unsigned long&&) @ 0x000000000a06f86b 4. /build/src/Functions/FunctionsStringSearch.h:137: DB::FunctionsStringSearch, (DB::ExecutionErrorPolicy)1, (DB::HaystackNeedleOrderIsConfigurable)1>::getReturnTypeImpl(std::vector, std::allocator>> const&) const @ 0x000000000cf68842 5. /build/src/Functions/IFunction.h:520: DB::IFunction::getReturnTypeImpl(std::vector> const&) const @ 0x000000000a06a2de 6. /build/src/Functions/IFunction.cpp:645: DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x0000000012d96b0c 7. /build/src/Functions/IFunction.cpp:577: DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x0000000012d9669c 8. /build/src/Functions/IFunction.cpp:606: DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x0000000012d96edc 9. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3544: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000014033cc9 10. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3838: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000014019a9e 11. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3980: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000014018e31 12. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:4304: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000014042fa7 13. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5605: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000014013749 14. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000140127f9 15. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000014011fce 16. /build/src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000001406ce8a 17. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000014973b42 18. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000001497268d 19. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000014974d24 20. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001492924b 21. /build/src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88641 22. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 23. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 24. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 25. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 26. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 27. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 28. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 29. ? @ 0x00007fbc6213eac3 30. ? @ 0x00007fbc621d0850 2025.07.28 12:00:39.286838 [ 17255 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function locate doesn't match: passed 0, should be 2 or 3: In scope SELECT locate(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, unsigned long&&) @ 0x000000000a06f86b 4. /build/src/Functions/FunctionsStringSearch.h:137: DB::FunctionsStringSearch, (DB::ExecutionErrorPolicy)1, (DB::HaystackNeedleOrderIsConfigurable)1>::getReturnTypeImpl(std::vector, std::allocator>> const&) const @ 0x000000000cf68842 5. /build/src/Functions/IFunction.h:520: DB::IFunction::getReturnTypeImpl(std::vector> const&) const @ 0x000000000a06a2de 6. /build/src/Functions/IFunction.cpp:645: DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x0000000012d96b0c 7. /build/src/Functions/IFunction.cpp:577: DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x0000000012d9669c 8. /build/src/Functions/IFunction.cpp:606: DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x0000000012d96edc 9. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3544: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000014033cc9 10. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3838: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000014019a9e 11. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3980: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000014018e31 12. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:4304: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000014042fa7 13. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5605: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000014013749 14. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000140127f9 15. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000014011fce 16. /build/src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000001406ce8a 17. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000014973b42 18. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000001497268d 19. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000014974d24 20. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001492924b 21. /build/src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88641 22. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 23. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 24. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 25. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 26. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 27. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 28. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 29. ? @ 0x00007fbc6213eac3 30. ? @ 0x00007fbc621d0850 2025.07.28 12:00:39.400137 [ 17255 ] {4212103b-5263-4bb9-8537-959db0f90aef} executeQuery: Code: 43. DB::Exception: Illegal type String of argument of function locate: In scope SELECT locate(1, 'abc'). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.6.10636.altinitytest (altinity build)) (from [::1]:43410) (comment: 00765_locate.sql) (query 4, line 5) (in query: SELECT locate(1, 'abc');), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000a06a8eb 4. /build/src/Functions/FunctionsStringSearch.h:152: DB::FunctionsStringSearch, (DB::ExecutionErrorPolicy)1, (DB::HaystackNeedleOrderIsConfigurable)1>::getReturnTypeImpl(std::vector, std::allocator>> const&) const @ 0x000000000cf688f1 5. /build/src/Functions/IFunction.h:520: DB::IFunction::getReturnTypeImpl(std::vector> const&) const @ 0x000000000a06a2de 6. /build/src/Functions/IFunction.cpp:645: DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x0000000012d96b0c 7. /build/src/Functions/IFunction.cpp:577: DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x0000000012d9669c 8. /build/src/Functions/IFunction.cpp:606: DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x0000000012d96edc 9. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3544: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000014033cc9 10. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3838: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000014019a9e 11. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3980: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000014018e31 12. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:4304: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000014042fa7 13. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5605: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000014013749 14. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000140127f9 15. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000014011fce 16. /build/src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000001406ce8a 17. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000014973b42 18. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000001497268d 19. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000014974d24 20. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001492924b 21. /build/src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88641 22. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 23. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 24. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 25. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 26. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 27. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 28. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 29. ? @ 0x00007fbc6213eac3 30. ? @ 0x00007fbc621d0850 2025.07.28 12:00:39.404023 [ 17255 ] {} TCPHandler: Code: 43. DB::Exception: Illegal type String of argument of function locate: In scope SELECT locate(1, 'abc'). (ILLEGAL_TYPE_OF_ARGUMENT), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000a06a8eb 4. /build/src/Functions/FunctionsStringSearch.h:152: DB::FunctionsStringSearch, (DB::ExecutionErrorPolicy)1, (DB::HaystackNeedleOrderIsConfigurable)1>::getReturnTypeImpl(std::vector, std::allocator>> const&) const @ 0x000000000cf688f1 5. /build/src/Functions/IFunction.h:520: DB::IFunction::getReturnTypeImpl(std::vector> const&) const @ 0x000000000a06a2de 6. /build/src/Functions/IFunction.cpp:645: DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x0000000012d96b0c 7. /build/src/Functions/IFunction.cpp:577: DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x0000000012d9669c 8. /build/src/Functions/IFunction.cpp:606: DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x0000000012d96edc 9. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3544: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000014033cc9 10. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3838: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000014019a9e 11. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3980: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000014018e31 12. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:4304: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000014042fa7 13. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5605: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000014013749 14. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000140127f9 15. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000014011fce 16. /build/src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000001406ce8a 17. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000014973b42 18. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000001497268d 19. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000014974d24 20. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001492924b 21. /build/src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88641 22. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 23. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 24. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 25. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 26. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 27. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 28. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 29. ? @ 0x00007fbc6213eac3 30. ? @ 0x00007fbc621d0850 2025.07.28 12:00:39.520121 [ 17255 ] {5cad8066-597f-4f90-b018-eefc399cfc88} executeQuery: Code: 43. DB::Exception: Illegal type String of argument of function locate: In scope SELECT locate('abc', 1). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.6.10636.altinitytest (altinity build)) (from [::1]:43410) (comment: 00765_locate.sql) (query 5, line 6) (in query: SELECT locate('abc', 1);), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000a06a8eb 4. /build/src/Functions/FunctionsStringSearch.h:146: DB::FunctionsStringSearch, (DB::ExecutionErrorPolicy)1, (DB::HaystackNeedleOrderIsConfigurable)1>::getReturnTypeImpl(std::vector, std::allocator>> const&) const @ 0x000000000cf689a6 5. /build/src/Functions/IFunction.h:520: DB::IFunction::getReturnTypeImpl(std::vector> const&) const @ 0x000000000a06a2de 6. /build/src/Functions/IFunction.cpp:645: DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x0000000012d96b0c 7. /build/src/Functions/IFunction.cpp:577: DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x0000000012d9669c 8. /build/src/Functions/IFunction.cpp:606: DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x0000000012d96edc 9. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3544: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000014033cc9 10. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3838: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000014019a9e 11. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3980: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000014018e31 12. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:4304: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000014042fa7 13. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5605: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000014013749 14. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000140127f9 15. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000014011fce 16. /build/src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000001406ce8a 17. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000014973b42 18. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000001497268d 19. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000014974d24 20. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001492924b 21. /build/src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88641 22. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 23. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 24. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 25. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 26. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 27. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 28. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 29. ? @ 0x00007fbc6213eac3 30. ? @ 0x00007fbc621d0850 2025.07.28 12:00:39.533523 [ 17255 ] {} TCPHandler: Code: 43. DB::Exception: Illegal type String of argument of function locate: In scope SELECT locate('abc', 1). (ILLEGAL_TYPE_OF_ARGUMENT), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000a06a8eb 4. /build/src/Functions/FunctionsStringSearch.h:146: DB::FunctionsStringSearch, (DB::ExecutionErrorPolicy)1, (DB::HaystackNeedleOrderIsConfigurable)1>::getReturnTypeImpl(std::vector, std::allocator>> const&) const @ 0x000000000cf689a6 5. /build/src/Functions/IFunction.h:520: DB::IFunction::getReturnTypeImpl(std::vector> const&) const @ 0x000000000a06a2de 6. /build/src/Functions/IFunction.cpp:645: DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x0000000012d96b0c 7. /build/src/Functions/IFunction.cpp:577: DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x0000000012d9669c 8. /build/src/Functions/IFunction.cpp:606: DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x0000000012d96edc 9. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3544: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000014033cc9 10. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3838: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000014019a9e 11. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3980: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000014018e31 12. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:4304: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000014042fa7 13. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5605: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000014013749 14. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000140127f9 15. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000014011fce 16. /build/src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000001406ce8a 17. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000014973b42 18. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000001497268d 19. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000014974d24 20. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001492924b 21. /build/src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88641 22. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 23. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 24. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 25. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 26. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 27. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 28. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 29. ? @ 0x00007fbc6213eac3 30. ? @ 0x00007fbc621d0850 2025.07.28 12:00:39.568560 [ 3960 ] {} test_13.rmt2 (7f9b740d-015c-470e-8cc6-8ba33be0dc63): auto DB::StorageReplicatedMergeTree::processQueueEntry(ReplicatedMergeTreeQueue::SelectedEntryPtr)::(anonymous class)::operator()(LogEntryPtr &) const: Code: 86. DB::HTTPException: Received error from remote server http://146b4357c08d:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Ftest%2F01165%2Ftest_13%2Frmt%2Freplicas%2F1&part=20250728_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.6.10636.altinitytest (altinity build)) '. (RECEIVED_ERROR_FROM_REMOTE_IO_SERVER), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.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 const&, int&&, String const&, unsigned long&&, String const&) @ 0x000000000feda8d9 4. /build/src/IO/HTTPCommon.cpp:104: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x000000000feda6e2 5. /build/src/IO/HTTPCommon.cpp:93: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x000000000feda537 6. /build/src/IO/ReadWriteBufferFromHTTP.cpp:277: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x000000001184a4c4 7. /build/src/IO/ReadWriteBufferFromHTTP.cpp:285: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x000000001184a615 8. /build/src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x000000001184ae59 9. /build/src/IO/ReadWriteBufferFromHTTP.cpp:472: void std::__function::__policy_invoker::__call_impl[abi:se190107]>(std::__function::__policy_storage const*) @ 0x000000001184cedd 10. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001184858b 11. /build/src/IO/ReadWriteBufferFromHTTP.cpp:465: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x000000001184bf0b 12. /build/src/IO/ReadBuffer.h:60: DB::ReadBuffer::next() @ 0x000000000a148c7b 13. /build/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) @ 0x0000000011849fb2 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]>&)>&, 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&) @ 0x0000000011841980 15. /build/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) @ 0x000000001621208e 16. /build/src/Storages/StorageReplicatedMergeTree.cpp:5228: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl[abi:se190107] const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000015f9a5fe 17. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000015ed8bfd 18. /build/src/Storages/StorageReplicatedMergeTree.cpp:2514: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x0000000015ec9aab 19. /build/src/Storages/StorageReplicatedMergeTree.cpp:2349: DB::StorageReplicatedMergeTree::executeLogEntry(DB::ReplicatedMergeTreeLogEntry&) @ 0x0000000015eba91b 20. /build/src/Storages/StorageReplicatedMergeTree.cpp:3876: bool std::__function::__policy_invoker&)>::__call_impl[abi:se190107])::$_1, bool (std::shared_ptr&)>>(std::__function::__policy_storage const*, std::shared_ptr&) @ 0x0000000015f9837e 21. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000165d6fc3 22. /build/src/Storages/StorageReplicatedMergeTree.cpp:3872: DB::StorageReplicatedMergeTree::processQueueEntry(std::shared_ptr) @ 0x0000000015efc18a 23. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001624c1b2 24. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000162f9c70 25. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x00000000162fa55a 26. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc6653 27. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000000fccc4c3 28. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc3d92 29. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fcca080 30. ? @ 0x00007fbc6213eac3 31. ? @ 0x00007fbc621d0850 (version 25.3.6.10636.altinitytest (altinity build)) 2025.07.28 12:00:39.654676 [ 17255 ] {84d4466c-16ac-4567-813f-d5dec9dee291} executeQuery: Code: 43. DB::Exception: Illegal type String of argument of function locate: In scope SELECT locate('abc', 'abc', 'abc'). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.6.10636.altinitytest (altinity build)) (from [::1]:43410) (comment: 00765_locate.sql) (query 6, line 7) (in query: SELECT locate('abc', 'abc', 'abc');), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000a06a8eb 4. /build/src/Functions/FunctionsStringSearch.h:160: DB::FunctionsStringSearch, (DB::ExecutionErrorPolicy)1, (DB::HaystackNeedleOrderIsConfigurable)1>::getReturnTypeImpl(std::vector, std::allocator>> const&) const @ 0x000000000cf68a4e 5. /build/src/Functions/IFunction.h:520: DB::IFunction::getReturnTypeImpl(std::vector> const&) const @ 0x000000000a06a2de 6. /build/src/Functions/IFunction.cpp:645: DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x0000000012d96b0c 7. /build/src/Functions/IFunction.cpp:577: DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x0000000012d9669c 8. /build/src/Functions/IFunction.cpp:606: DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x0000000012d96edc 9. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3544: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000014033cc9 10. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3838: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000014019a9e 11. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3980: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000014018e31 12. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:4304: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000014042fa7 13. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5605: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000014013749 14. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000140127f9 15. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000014011fce 16. /build/src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000001406ce8a 17. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000014973b42 18. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000001497268d 19. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000014974d24 20. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001492924b 21. /build/src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88641 22. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 23. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 24. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 25. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 26. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 27. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 28. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 29. ? @ 0x00007fbc6213eac3 30. ? @ 0x00007fbc621d0850 2025.07.28 12:00:39.658428 [ 17255 ] {} TCPHandler: Code: 43. DB::Exception: Illegal type String of argument of function locate: In scope SELECT locate('abc', 'abc', 'abc'). (ILLEGAL_TYPE_OF_ARGUMENT), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000a06a8eb 4. /build/src/Functions/FunctionsStringSearch.h:160: DB::FunctionsStringSearch, (DB::ExecutionErrorPolicy)1, (DB::HaystackNeedleOrderIsConfigurable)1>::getReturnTypeImpl(std::vector, std::allocator>> const&) const @ 0x000000000cf68a4e 5. /build/src/Functions/IFunction.h:520: DB::IFunction::getReturnTypeImpl(std::vector> const&) const @ 0x000000000a06a2de 6. /build/src/Functions/IFunction.cpp:645: DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x0000000012d96b0c 7. /build/src/Functions/IFunction.cpp:577: DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x0000000012d9669c 8. /build/src/Functions/IFunction.cpp:606: DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x0000000012d96edc 9. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3544: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000014033cc9 10. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3838: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000014019a9e 11. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3980: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000014018e31 12. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:4304: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000014042fa7 13. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5605: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000014013749 14. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000140127f9 15. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000014011fce 16. /build/src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000001406ce8a 17. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000014973b42 18. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000001497268d 19. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000014974d24 20. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001492924b 21. /build/src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88641 22. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 23. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 24. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 25. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 26. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 27. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 28. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 29. ? @ 0x00007fbc6213eac3 30. ? @ 0x00007fbc621d0850 2025.07.28 12:00:40.744338 [ 3967 ] {} test_13.rmt2 (7f9b740d-015c-470e-8cc6-8ba33be0dc63): auto DB::StorageReplicatedMergeTree::processQueueEntry(ReplicatedMergeTreeQueue::SelectedEntryPtr)::(anonymous class)::operator()(LogEntryPtr &) const: Code: 86. DB::HTTPException: Received error from remote server http://146b4357c08d:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Ftest%2F01165%2Ftest_13%2Frmt%2Freplicas%2F1&part=20250728_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.6.10636.altinitytest (altinity build)) '. (RECEIVED_ERROR_FROM_REMOTE_IO_SERVER), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.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 const&, int&&, String const&, unsigned long&&, String const&) @ 0x000000000feda8d9 4. /build/src/IO/HTTPCommon.cpp:104: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x000000000feda6e2 5. /build/src/IO/HTTPCommon.cpp:93: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x000000000feda537 6. /build/src/IO/ReadWriteBufferFromHTTP.cpp:277: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x000000001184a4c4 7. /build/src/IO/ReadWriteBufferFromHTTP.cpp:285: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x000000001184a615 8. /build/src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x000000001184ae59 9. /build/src/IO/ReadWriteBufferFromHTTP.cpp:472: void std::__function::__policy_invoker::__call_impl[abi:se190107]>(std::__function::__policy_storage const*) @ 0x000000001184cedd 10. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001184858b 11. /build/src/IO/ReadWriteBufferFromHTTP.cpp:465: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x000000001184bf0b 12. /build/src/IO/ReadBuffer.h:60: DB::ReadBuffer::next() @ 0x000000000a148c7b 13. /build/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) @ 0x0000000011849fb2 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]>&)>&, 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&) @ 0x0000000011841980 15. /build/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) @ 0x000000001621208e 16. /build/src/Storages/StorageReplicatedMergeTree.cpp:5228: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl[abi:se190107] const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000015f9a5fe 17. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000015ed8bfd 18. /build/src/Storages/StorageReplicatedMergeTree.cpp:2514: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x0000000015ec9aab 19. /build/src/Storages/StorageReplicatedMergeTree.cpp:2349: DB::StorageReplicatedMergeTree::executeLogEntry(DB::ReplicatedMergeTreeLogEntry&) @ 0x0000000015eba91b 20. /build/src/Storages/StorageReplicatedMergeTree.cpp:3876: bool std::__function::__policy_invoker&)>::__call_impl[abi:se190107])::$_1, bool (std::shared_ptr&)>>(std::__function::__policy_storage const*, std::shared_ptr&) @ 0x0000000015f9837e 21. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000165d6fc3 22. /build/src/Storages/StorageReplicatedMergeTree.cpp:3872: DB::StorageReplicatedMergeTree::processQueueEntry(std::shared_ptr) @ 0x0000000015efc18a 23. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001624c1b2 24. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000162f9c70 25. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x00000000162fa55a 26. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc6653 27. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000000fccc4c3 28. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc3d92 29. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fcca080 30. ? @ 0x00007fbc6213eac3 31. ? @ 0x00007fbc621d0850 (version 25.3.6.10636.altinitytest (altinity build)) 2025.07.28 12:00:40.913383 [ 4446 ] {7f32e11d-0977-4aff-b5f0-8c717bd79959} executeQuery: Code: 219. DB::Exception: New table appeared in database being dropped or detached. Try again. (DATABASE_NOT_EMPTY) (version 25.3.6.10636.altinitytest (altinity build)) (from [::1]:57302) (comment: 02952_conjunction_optimization.sql) (in query: DROP DATABASE IF EXISTS test_wz8e9oq7 SYNC ), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000000a074fcb 4. /build/src/Interpreters/DatabaseCatalog.cpp:608: DB::DatabaseCatalog::detachDatabase(std::shared_ptr, String const&, bool, bool) @ 0x00000000144f41b9 5. /build/src/Interpreters/InterpreterDropQuery.cpp:482: DB::InterpreterDropQuery::executeToDatabaseImpl(DB::ASTDropQuery const&, std::shared_ptr&, std::vector, DB::UUIDTag>, std::allocator, DB::UUIDTag>>>&) @ 0x00000000149179be 6. /build/src/Interpreters/InterpreterDropQuery.cpp:363: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x0000000014913988 7. /build/src/Interpreters/InterpreterDropQuery.cpp:99: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000014913142 8. /build/src/Interpreters/InterpreterDropQuery.cpp:72: DB::InterpreterDropQuery::execute() @ 0x0000000014912b65 9. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88dc9 10. /build/src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x0000000014c8ca7b 11. /build/src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000001686da12 12. /build/src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x0000000016870807 13. /build/src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x0000000016907e99 14. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 15. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 16. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 17. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 18. ? @ 0x00007fbc6213eac3 19. ? @ 0x00007fbc621d0850 2025.07.28 12:00:40.925388 [ 4446 ] {7f32e11d-0977-4aff-b5f0-8c717bd79959} 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. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000000a074fcb 4. /build/src/Interpreters/DatabaseCatalog.cpp:608: DB::DatabaseCatalog::detachDatabase(std::shared_ptr, String const&, bool, bool) @ 0x00000000144f41b9 5. /build/src/Interpreters/InterpreterDropQuery.cpp:482: DB::InterpreterDropQuery::executeToDatabaseImpl(DB::ASTDropQuery const&, std::shared_ptr&, std::vector, DB::UUIDTag>, std::allocator, DB::UUIDTag>>>&) @ 0x00000000149179be 6. /build/src/Interpreters/InterpreterDropQuery.cpp:363: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x0000000014913988 7. /build/src/Interpreters/InterpreterDropQuery.cpp:99: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000014913142 8. /build/src/Interpreters/InterpreterDropQuery.cpp:72: DB::InterpreterDropQuery::execute() @ 0x0000000014912b65 9. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88dc9 10. /build/src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x0000000014c8ca7b 11. /build/src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000001686da12 12. /build/src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x0000000016870807 13. /build/src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x0000000016907e99 14. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 15. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 16. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 17. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 18. ? @ 0x00007fbc6213eac3 19. ? @ 0x00007fbc621d0850 (version 25.3.6.10636.altinitytest (altinity build)) 2025.07.28 12:00:41.266259 [ 3963 ] {} test_13.rmt2 (7f9b740d-015c-470e-8cc6-8ba33be0dc63): auto DB::StorageReplicatedMergeTree::processQueueEntry(ReplicatedMergeTreeQueue::SelectedEntryPtr)::(anonymous class)::operator()(LogEntryPtr &) const: Code: 86. DB::HTTPException: Received error from remote server http://146b4357c08d:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Ftest%2F01165%2Ftest_13%2Frmt%2Freplicas%2F1&part=20250728_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.6.10636.altinitytest (altinity build)) '. (RECEIVED_ERROR_FROM_REMOTE_IO_SERVER), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.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 const&, int&&, String const&, unsigned long&&, String const&) @ 0x000000000feda8d9 4. /build/src/IO/HTTPCommon.cpp:104: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x000000000feda6e2 5. /build/src/IO/HTTPCommon.cpp:93: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x000000000feda537 6. /build/src/IO/ReadWriteBufferFromHTTP.cpp:277: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x000000001184a4c4 7. /build/src/IO/ReadWriteBufferFromHTTP.cpp:285: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x000000001184a615 8. /build/src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x000000001184ae59 9. /build/src/IO/ReadWriteBufferFromHTTP.cpp:472: void std::__function::__policy_invoker::__call_impl[abi:se190107]>(std::__function::__policy_storage const*) @ 0x000000001184cedd 10. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001184858b 11. /build/src/IO/ReadWriteBufferFromHTTP.cpp:465: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x000000001184bf0b 12. /build/src/IO/ReadBuffer.h:60: DB::ReadBuffer::next() @ 0x000000000a148c7b 13. /build/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) @ 0x0000000011849fb2 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]>&)>&, 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&) @ 0x0000000011841980 15. /build/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) @ 0x000000001621208e 16. /build/src/Storages/StorageReplicatedMergeTree.cpp:5228: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl[abi:se190107] const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000015f9a5fe 17. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000015ed8bfd 18. /build/src/Storages/StorageReplicatedMergeTree.cpp:2514: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x0000000015ec9aab 19. /build/src/Storages/StorageReplicatedMergeTree.cpp:2349: DB::StorageReplicatedMergeTree::executeLogEntry(DB::ReplicatedMergeTreeLogEntry&) @ 0x0000000015eba91b 20. /build/src/Storages/StorageReplicatedMergeTree.cpp:3876: bool std::__function::__policy_invoker&)>::__call_impl[abi:se190107])::$_1, bool (std::shared_ptr&)>>(std::__function::__policy_storage const*, std::shared_ptr&) @ 0x0000000015f9837e 21. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000165d6fc3 22. /build/src/Storages/StorageReplicatedMergeTree.cpp:3872: DB::StorageReplicatedMergeTree::processQueueEntry(std::shared_ptr) @ 0x0000000015efc18a 23. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001624c1b2 24. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000162f9c70 25. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x00000000162fa55a 26. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc6653 27. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000000fccc4c3 28. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc3d92 29. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fcca080 30. ? @ 0x00007fbc6213eac3 31. ? @ 0x00007fbc621d0850 (version 25.3.6.10636.altinitytest (altinity build)) 2025.07.28 12:00:41.588966 [ 3976 ] {} test_13.rmt2 (7f9b740d-015c-470e-8cc6-8ba33be0dc63): auto DB::StorageReplicatedMergeTree::processQueueEntry(ReplicatedMergeTreeQueue::SelectedEntryPtr)::(anonymous class)::operator()(LogEntryPtr &) const: Code: 86. DB::HTTPException: Received error from remote server http://146b4357c08d:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Ftest%2F01165%2Ftest_13%2Frmt%2Freplicas%2F1&part=20250728_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.6.10636.altinitytest (altinity build)) '. (RECEIVED_ERROR_FROM_REMOTE_IO_SERVER), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.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 const&, int&&, String const&, unsigned long&&, String const&) @ 0x000000000feda8d9 4. /build/src/IO/HTTPCommon.cpp:104: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x000000000feda6e2 5. /build/src/IO/HTTPCommon.cpp:93: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x000000000feda537 6. /build/src/IO/ReadWriteBufferFromHTTP.cpp:277: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x000000001184a4c4 7. /build/src/IO/ReadWriteBufferFromHTTP.cpp:285: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x000000001184a615 8. /build/src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x000000001184ae59 9. /build/src/IO/ReadWriteBufferFromHTTP.cpp:472: void std::__function::__policy_invoker::__call_impl[abi:se190107]>(std::__function::__policy_storage const*) @ 0x000000001184cedd 10. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001184858b 11. /build/src/IO/ReadWriteBufferFromHTTP.cpp:465: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x000000001184bf0b 12. /build/src/IO/ReadBuffer.h:60: DB::ReadBuffer::next() @ 0x000000000a148c7b 13. /build/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) @ 0x0000000011849fb2 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]>&)>&, 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&) @ 0x0000000011841980 15. /build/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) @ 0x000000001621208e 16. /build/src/Storages/StorageReplicatedMergeTree.cpp:5228: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl[abi:se190107] const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000015f9a5fe 17. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000015ed8bfd 18. /build/src/Storages/StorageReplicatedMergeTree.cpp:2514: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x0000000015ec9aab 19. /build/src/Storages/StorageReplicatedMergeTree.cpp:2349: DB::StorageReplicatedMergeTree::executeLogEntry(DB::ReplicatedMergeTreeLogEntry&) @ 0x0000000015eba91b 20. /build/src/Storages/StorageReplicatedMergeTree.cpp:3876: bool std::__function::__policy_invoker&)>::__call_impl[abi:se190107])::$_1, bool (std::shared_ptr&)>>(std::__function::__policy_storage const*, std::shared_ptr&) @ 0x0000000015f9837e 21. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000165d6fc3 22. /build/src/Storages/StorageReplicatedMergeTree.cpp:3872: DB::StorageReplicatedMergeTree::processQueueEntry(std::shared_ptr) @ 0x0000000015efc18a 23. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001624c1b2 24. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000162f9c70 25. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x00000000162fa55a 26. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc6653 27. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000000fccc4c3 28. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc3d92 29. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fcca080 30. ? @ 0x00007fbc6213eac3 31. ? @ 0x00007fbc621d0850 (version 25.3.6.10636.altinitytest (altinity build)) 2025.07.28 12:00:41.829969 [ 17255 ] {fc34f33b-bc64-470f-9d19-b7060a1f0bda} executeQuery: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION) (version 25.3.6.10636.altinitytest (altinity build)) (from [::1]:54820) (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. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x000000000c25bc4b 4. /build/src/Access/SettingsConstraints.cpp:343: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000138596e3 5. /build/src/Access/SettingsConstraints.cpp:300: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000013858faf 6. /build/src/Access/SettingsConstraints.cpp:194: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges const&, DB::SettingSource) const @ 0x00000000138591b3 7. /build/src/Interpreters/Context.cpp:2722: DB::Context::checkSettingsConstraints(DB::SettingsChanges const&, DB::SettingSource) @ 0x0000000014436509 8. /build/src/Interpreters/InterpreterSetQuery.cpp:28: DB::InterpreterSetQuery::execute() @ 0x00000000149e240a 9. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88dc9 10. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 11. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 12. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 13. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 14. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 16. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 17. ? @ 0x00007fbc6213eac3 18. ? @ 0x00007fbc621d0850 2025.07.28 12:00:41.848571 [ 17255 ] {} 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. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x000000000c25bc4b 4. /build/src/Access/SettingsConstraints.cpp:343: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000138596e3 5. /build/src/Access/SettingsConstraints.cpp:300: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000013858faf 6. /build/src/Access/SettingsConstraints.cpp:194: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges const&, DB::SettingSource) const @ 0x00000000138591b3 7. /build/src/Interpreters/Context.cpp:2722: DB::Context::checkSettingsConstraints(DB::SettingsChanges const&, DB::SettingSource) @ 0x0000000014436509 8. /build/src/Interpreters/InterpreterSetQuery.cpp:28: DB::InterpreterSetQuery::execute() @ 0x00000000149e240a 9. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88dc9 10. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 11. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 12. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 13. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 14. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 16. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 17. ? @ 0x00007fbc6213eac3 18. ? @ 0x00007fbc621d0850 2025.07.28 12:00:41.872538 [ 3965 ] {} test_13.rmt2 (7f9b740d-015c-470e-8cc6-8ba33be0dc63): auto DB::StorageReplicatedMergeTree::processQueueEntry(ReplicatedMergeTreeQueue::SelectedEntryPtr)::(anonymous class)::operator()(LogEntryPtr &) const: Code: 86. DB::HTTPException: Received error from remote server http://146b4357c08d:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Ftest%2F01165%2Ftest_13%2Frmt%2Freplicas%2F1&part=20250728_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.6.10636.altinitytest (altinity build)) '. (RECEIVED_ERROR_FROM_REMOTE_IO_SERVER), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.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 const&, int&&, String const&, unsigned long&&, String const&) @ 0x000000000feda8d9 4. /build/src/IO/HTTPCommon.cpp:104: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x000000000feda6e2 5. /build/src/IO/HTTPCommon.cpp:93: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x000000000feda537 6. /build/src/IO/ReadWriteBufferFromHTTP.cpp:277: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x000000001184a4c4 7. /build/src/IO/ReadWriteBufferFromHTTP.cpp:285: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x000000001184a615 8. /build/src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x000000001184ae59 9. /build/src/IO/ReadWriteBufferFromHTTP.cpp:472: void std::__function::__policy_invoker::__call_impl[abi:se190107]>(std::__function::__policy_storage const*) @ 0x000000001184cedd 10. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001184858b 11. /build/src/IO/ReadWriteBufferFromHTTP.cpp:465: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x000000001184bf0b 12. /build/src/IO/ReadBuffer.h:60: DB::ReadBuffer::next() @ 0x000000000a148c7b 13. /build/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) @ 0x0000000011849fb2 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]>&)>&, 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&) @ 0x0000000011841980 15. /build/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) @ 0x000000001621208e 16. /build/src/Storages/StorageReplicatedMergeTree.cpp:5228: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl[abi:se190107] const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000015f9a5fe 17. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000015ed8bfd 18. /build/src/Storages/StorageReplicatedMergeTree.cpp:2514: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x0000000015ec9aab 19. /build/src/Storages/StorageReplicatedMergeTree.cpp:2349: DB::StorageReplicatedMergeTree::executeLogEntry(DB::ReplicatedMergeTreeLogEntry&) @ 0x0000000015eba91b 20. /build/src/Storages/StorageReplicatedMergeTree.cpp:3876: bool std::__function::__policy_invoker&)>::__call_impl[abi:se190107])::$_1, bool (std::shared_ptr&)>>(std::__function::__policy_storage const*, std::shared_ptr&) @ 0x0000000015f9837e 21. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000165d6fc3 22. /build/src/Storages/StorageReplicatedMergeTree.cpp:3872: DB::StorageReplicatedMergeTree::processQueueEntry(std::shared_ptr) @ 0x0000000015efc18a 23. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001624c1b2 24. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000162f9c70 25. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x00000000162fa55a 26. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc6653 27. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000000fccc4c3 28. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc3d92 29. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fcca080 30. ? @ 0x00007fbc6213eac3 31. ? @ 0x00007fbc621d0850 (version 25.3.6.10636.altinitytest (altinity build)) 2025.07.28 12:00:42.161018 [ 4900 ] {41a4f84e-d8b2-4537-82d6-1050e7a6d402} executeQuery: Code: 117. DB::Exception: Projection non_existing_projection is specified in setting force_optimize_projection_name but not used. (INCORRECT_DATA) (version 25.3.6.10636.altinitytest (altinity build)) (from [::1]:43462) (comment: 02906_force_optimize_projection_name.sql) (query 5, line 20) (in query: SELECT name FROM test GROUP BY name SETTINGS force_optimize_projection_name='non_existing_projection';), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000a9b78ab 4. /build/src/Processors/QueryPlan/Optimizations/optimizeTree.cpp:247: DB::QueryPlanOptimizations::optimizeTreeSecondPass(DB::QueryPlanOptimizationSettings const&, DB::QueryPlan::Node&, std::list>&) @ 0x0000000016eada45 5. /build/src/Processors/QueryPlan/QueryPlan.cpp:487: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x0000000016e0055c 6. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:275: DB::InterpreterSelectQueryAnalyzer::buildQueryPipeline() @ 0x0000000014974614 7. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:242: DB::InterpreterSelectQueryAnalyzer::execute() @ 0x000000001497439e 8. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88dc9 9. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 10. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 11. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 12. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 13. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 14. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 15. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 16. ? @ 0x00007fbc6213eac3 17. ? @ 0x00007fbc621d0850 2025.07.28 12:00:42.172061 [ 4900 ] {} TCPHandler: Code: 117. DB::Exception: Projection non_existing_projection is specified in setting force_optimize_projection_name but not used. (INCORRECT_DATA), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000a9b78ab 4. /build/src/Processors/QueryPlan/Optimizations/optimizeTree.cpp:247: DB::QueryPlanOptimizations::optimizeTreeSecondPass(DB::QueryPlanOptimizationSettings const&, DB::QueryPlan::Node&, std::list>&) @ 0x0000000016eada45 5. /build/src/Processors/QueryPlan/QueryPlan.cpp:487: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x0000000016e0055c 6. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:275: DB::InterpreterSelectQueryAnalyzer::buildQueryPipeline() @ 0x0000000014974614 7. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:242: DB::InterpreterSelectQueryAnalyzer::execute() @ 0x000000001497439e 8. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88dc9 9. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 10. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 11. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 12. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 13. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 14. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 15. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 16. ? @ 0x00007fbc6213eac3 17. ? @ 0x00007fbc621d0850 2025.07.28 12:00:42.395729 [ 4900 ] {a80d2426-802c-460a-b8db-26c891655ff5} executeQuery: Code: 117. DB::Exception: Projection projection_name is specified in setting force_optimize_projection_name but not used. (INCORRECT_DATA) (version 25.3.6.10636.altinitytest (altinity build)) (from [::1]:43462) (comment: 02906_force_optimize_projection_name.sql) (query 6, line 22) (in query: SELECT name FROM test SETTINGS force_optimize_projection_name='projection_name';), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000a9b78ab 4. /build/src/Processors/QueryPlan/Optimizations/optimizeTree.cpp:247: DB::QueryPlanOptimizations::optimizeTreeSecondPass(DB::QueryPlanOptimizationSettings const&, DB::QueryPlan::Node&, std::list>&) @ 0x0000000016eada45 5. /build/src/Processors/QueryPlan/QueryPlan.cpp:487: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x0000000016e0055c 6. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:275: DB::InterpreterSelectQueryAnalyzer::buildQueryPipeline() @ 0x0000000014974614 7. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:242: DB::InterpreterSelectQueryAnalyzer::execute() @ 0x000000001497439e 8. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88dc9 9. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 10. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 11. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 12. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 13. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 14. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 15. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 16. ? @ 0x00007fbc6213eac3 17. ? @ 0x00007fbc621d0850 2025.07.28 12:00:42.411807 [ 4900 ] {} TCPHandler: Code: 117. DB::Exception: Projection projection_name is specified in setting force_optimize_projection_name but not used. (INCORRECT_DATA), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000a9b78ab 4. /build/src/Processors/QueryPlan/Optimizations/optimizeTree.cpp:247: DB::QueryPlanOptimizations::optimizeTreeSecondPass(DB::QueryPlanOptimizationSettings const&, DB::QueryPlan::Node&, std::list>&) @ 0x0000000016eada45 5. /build/src/Processors/QueryPlan/QueryPlan.cpp:487: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x0000000016e0055c 6. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:275: DB::InterpreterSelectQueryAnalyzer::buildQueryPipeline() @ 0x0000000014974614 7. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:242: DB::InterpreterSelectQueryAnalyzer::execute() @ 0x000000001497439e 8. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88dc9 9. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 10. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 11. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 12. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 13. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 14. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 15. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 16. ? @ 0x00007fbc6213eac3 17. ? @ 0x00007fbc621d0850 2025.07.28 12:00:42.761080 [ 3961 ] {} test_13.rmt2 (7f9b740d-015c-470e-8cc6-8ba33be0dc63): auto DB::StorageReplicatedMergeTree::processQueueEntry(ReplicatedMergeTreeQueue::SelectedEntryPtr)::(anonymous class)::operator()(LogEntryPtr &) const: Code: 86. DB::HTTPException: Received error from remote server http://146b4357c08d:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Ftest%2F01165%2Ftest_13%2Frmt%2Freplicas%2F1&part=20250728_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.6.10636.altinitytest (altinity build)) '. (RECEIVED_ERROR_FROM_REMOTE_IO_SERVER), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.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 const&, int&&, String const&, unsigned long&&, String const&) @ 0x000000000feda8d9 4. /build/src/IO/HTTPCommon.cpp:104: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x000000000feda6e2 5. /build/src/IO/HTTPCommon.cpp:93: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x000000000feda537 6. /build/src/IO/ReadWriteBufferFromHTTP.cpp:277: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x000000001184a4c4 7. /build/src/IO/ReadWriteBufferFromHTTP.cpp:285: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x000000001184a615 8. /build/src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x000000001184ae59 9. /build/src/IO/ReadWriteBufferFromHTTP.cpp:472: void std::__function::__policy_invoker::__call_impl[abi:se190107]>(std::__function::__policy_storage const*) @ 0x000000001184cedd 10. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001184858b 11. /build/src/IO/ReadWriteBufferFromHTTP.cpp:465: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x000000001184bf0b 12. /build/src/IO/ReadBuffer.h:60: DB::ReadBuffer::next() @ 0x000000000a148c7b 13. /build/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) @ 0x0000000011849fb2 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]>&)>&, 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&) @ 0x0000000011841980 15. /build/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) @ 0x000000001621208e 16. /build/src/Storages/StorageReplicatedMergeTree.cpp:5228: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl[abi:se190107] const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000015f9a5fe 17. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000015ed8bfd 18. /build/src/Storages/StorageReplicatedMergeTree.cpp:2514: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x0000000015ec9aab 19. /build/src/Storages/StorageReplicatedMergeTree.cpp:2349: DB::StorageReplicatedMergeTree::executeLogEntry(DB::ReplicatedMergeTreeLogEntry&) @ 0x0000000015eba91b 20. /build/src/Storages/StorageReplicatedMergeTree.cpp:3876: bool std::__function::__policy_invoker&)>::__call_impl[abi:se190107])::$_1, bool (std::shared_ptr&)>>(std::__function::__policy_storage const*, std::shared_ptr&) @ 0x0000000015f9837e 21. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000165d6fc3 22. /build/src/Storages/StorageReplicatedMergeTree.cpp:3872: DB::StorageReplicatedMergeTree::processQueueEntry(std::shared_ptr) @ 0x0000000015efc18a 23. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001624c1b2 24. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000162f9c70 25. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x00000000162fa55a 26. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc6653 27. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000000fccc4c3 28. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc3d92 29. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fcca080 30. ? @ 0x00007fbc6213eac3 31. ? @ 0x00007fbc621d0850 (version 25.3.6.10636.altinitytest (altinity build)) 2025.07.28 12:00:43.595244 [ 3974 ] {} test_13.rmt2 (7f9b740d-015c-470e-8cc6-8ba33be0dc63): auto DB::StorageReplicatedMergeTree::processQueueEntry(ReplicatedMergeTreeQueue::SelectedEntryPtr)::(anonymous class)::operator()(LogEntryPtr &) const: Code: 86. DB::HTTPException: Received error from remote server http://146b4357c08d:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Ftest%2F01165%2Ftest_13%2Frmt%2Freplicas%2F1&part=20250728_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.6.10636.altinitytest (altinity build)) '. (RECEIVED_ERROR_FROM_REMOTE_IO_SERVER), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.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 const&, int&&, String const&, unsigned long&&, String const&) @ 0x000000000feda8d9 4. /build/src/IO/HTTPCommon.cpp:104: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x000000000feda6e2 5. /build/src/IO/HTTPCommon.cpp:93: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x000000000feda537 6. /build/src/IO/ReadWriteBufferFromHTTP.cpp:277: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x000000001184a4c4 7. /build/src/IO/ReadWriteBufferFromHTTP.cpp:285: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x000000001184a615 8. /build/src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x000000001184ae59 9. /build/src/IO/ReadWriteBufferFromHTTP.cpp:472: void std::__function::__policy_invoker::__call_impl[abi:se190107]>(std::__function::__policy_storage const*) @ 0x000000001184cedd 10. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001184858b 11. /build/src/IO/ReadWriteBufferFromHTTP.cpp:465: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x000000001184bf0b 12. /build/src/IO/ReadBuffer.h:60: DB::ReadBuffer::next() @ 0x000000000a148c7b 13. /build/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) @ 0x0000000011849fb2 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]>&)>&, 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&) @ 0x0000000011841980 15. /build/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) @ 0x000000001621208e 16. /build/src/Storages/StorageReplicatedMergeTree.cpp:5228: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl[abi:se190107] const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000015f9a5fe 17. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000015ed8bfd 18. /build/src/Storages/StorageReplicatedMergeTree.cpp:2514: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x0000000015ec9aab 19. /build/src/Storages/StorageReplicatedMergeTree.cpp:2349: DB::StorageReplicatedMergeTree::executeLogEntry(DB::ReplicatedMergeTreeLogEntry&) @ 0x0000000015eba91b 20. /build/src/Storages/StorageReplicatedMergeTree.cpp:3876: bool std::__function::__policy_invoker&)>::__call_impl[abi:se190107])::$_1, bool (std::shared_ptr&)>>(std::__function::__policy_storage const*, std::shared_ptr&) @ 0x0000000015f9837e 21. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000165d6fc3 22. /build/src/Storages/StorageReplicatedMergeTree.cpp:3872: DB::StorageReplicatedMergeTree::processQueueEntry(std::shared_ptr) @ 0x0000000015efc18a 23. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001624c1b2 24. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000162f9c70 25. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x00000000162fa55a 26. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc6653 27. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000000fccc4c3 28. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc3d92 29. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fcca080 30. ? @ 0x00007fbc6213eac3 31. ? @ 0x00007fbc621d0850 (version 25.3.6.10636.altinitytest (altinity build)) 2025.07.28 12:00:44.042072 [ 3970 ] {} test_13.rmt2 (7f9b740d-015c-470e-8cc6-8ba33be0dc63): auto DB::StorageReplicatedMergeTree::processQueueEntry(ReplicatedMergeTreeQueue::SelectedEntryPtr)::(anonymous class)::operator()(LogEntryPtr &) const: Code: 86. DB::HTTPException: Received error from remote server http://146b4357c08d:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Ftest%2F01165%2Ftest_13%2Frmt%2Freplicas%2F1&part=20250728_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.6.10636.altinitytest (altinity build)) '. (RECEIVED_ERROR_FROM_REMOTE_IO_SERVER), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.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 const&, int&&, String const&, unsigned long&&, String const&) @ 0x000000000feda8d9 4. /build/src/IO/HTTPCommon.cpp:104: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x000000000feda6e2 5. /build/src/IO/HTTPCommon.cpp:93: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x000000000feda537 6. /build/src/IO/ReadWriteBufferFromHTTP.cpp:277: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x000000001184a4c4 7. /build/src/IO/ReadWriteBufferFromHTTP.cpp:285: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x000000001184a615 8. /build/src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x000000001184ae59 9. /build/src/IO/ReadWriteBufferFromHTTP.cpp:472: void std::__function::__policy_invoker::__call_impl[abi:se190107]>(std::__function::__policy_storage const*) @ 0x000000001184cedd 10. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001184858b 11. /build/src/IO/ReadWriteBufferFromHTTP.cpp:465: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x000000001184bf0b 12. /build/src/IO/ReadBuffer.h:60: DB::ReadBuffer::next() @ 0x000000000a148c7b 13. /build/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) @ 0x0000000011849fb2 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]>&)>&, 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&) @ 0x0000000011841980 15. /build/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) @ 0x000000001621208e 16. /build/src/Storages/StorageReplicatedMergeTree.cpp:5228: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl[abi:se190107] const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000015f9a5fe 17. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000015ed8bfd 18. /build/src/Storages/StorageReplicatedMergeTree.cpp:2514: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x0000000015ec9aab 19. /build/src/Storages/StorageReplicatedMergeTree.cpp:2349: DB::StorageReplicatedMergeTree::executeLogEntry(DB::ReplicatedMergeTreeLogEntry&) @ 0x0000000015eba91b 20. /build/src/Storages/StorageReplicatedMergeTree.cpp:3876: bool std::__function::__policy_invoker&)>::__call_impl[abi:se190107])::$_1, bool (std::shared_ptr&)>>(std::__function::__policy_storage const*, std::shared_ptr&) @ 0x0000000015f9837e 21. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000165d6fc3 22. /build/src/Storages/StorageReplicatedMergeTree.cpp:3872: DB::StorageReplicatedMergeTree::processQueueEntry(std::shared_ptr) @ 0x0000000015efc18a 23. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001624c1b2 24. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000162f9c70 25. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x00000000162fa55a 26. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc6653 27. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000000fccc4c3 28. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc3d92 29. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fcca080 30. ? @ 0x00007fbc6213eac3 31. ? @ 0x00007fbc621d0850 (version 25.3.6.10636.altinitytest (altinity build)) 2025.07.28 12:00:44.333408 [ 3963 ] {} test_13.rmt2 (7f9b740d-015c-470e-8cc6-8ba33be0dc63): auto DB::StorageReplicatedMergeTree::processQueueEntry(ReplicatedMergeTreeQueue::SelectedEntryPtr)::(anonymous class)::operator()(LogEntryPtr &) const: Code: 86. DB::HTTPException: Received error from remote server http://146b4357c08d:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Ftest%2F01165%2Ftest_13%2Frmt%2Freplicas%2F1&part=20250728_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.6.10636.altinitytest (altinity build)) '. (RECEIVED_ERROR_FROM_REMOTE_IO_SERVER), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.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 const&, int&&, String const&, unsigned long&&, String const&) @ 0x000000000feda8d9 4. /build/src/IO/HTTPCommon.cpp:104: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x000000000feda6e2 5. /build/src/IO/HTTPCommon.cpp:93: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x000000000feda537 6. /build/src/IO/ReadWriteBufferFromHTTP.cpp:277: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x000000001184a4c4 7. /build/src/IO/ReadWriteBufferFromHTTP.cpp:285: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x000000001184a615 8. /build/src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x000000001184ae59 9. /build/src/IO/ReadWriteBufferFromHTTP.cpp:472: void std::__function::__policy_invoker::__call_impl[abi:se190107]>(std::__function::__policy_storage const*) @ 0x000000001184cedd 10. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001184858b 11. /build/src/IO/ReadWriteBufferFromHTTP.cpp:465: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x000000001184bf0b 12. /build/src/IO/ReadBuffer.h:60: DB::ReadBuffer::next() @ 0x000000000a148c7b 13. /build/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) @ 0x0000000011849fb2 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]>&)>&, 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&) @ 0x0000000011841980 15. /build/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) @ 0x000000001621208e 16. /build/src/Storages/StorageReplicatedMergeTree.cpp:5228: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl[abi:se190107] const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000015f9a5fe 17. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000015ed8bfd 18. /build/src/Storages/StorageReplicatedMergeTree.cpp:2514: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x0000000015ec9aab 19. /build/src/Storages/StorageReplicatedMergeTree.cpp:2349: DB::StorageReplicatedMergeTree::executeLogEntry(DB::ReplicatedMergeTreeLogEntry&) @ 0x0000000015eba91b 20. /build/src/Storages/StorageReplicatedMergeTree.cpp:3876: bool std::__function::__policy_invoker&)>::__call_impl[abi:se190107])::$_1, bool (std::shared_ptr&)>>(std::__function::__policy_storage const*, std::shared_ptr&) @ 0x0000000015f9837e 21. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000165d6fc3 22. /build/src/Storages/StorageReplicatedMergeTree.cpp:3872: DB::StorageReplicatedMergeTree::processQueueEntry(std::shared_ptr) @ 0x0000000015efc18a 23. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001624c1b2 24. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000162f9c70 25. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x00000000162fa55a 26. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc6653 27. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000000fccc4c3 28. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc3d92 29. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fcca080 30. ? @ 0x00007fbc6213eac3 31. ? @ 0x00007fbc621d0850 (version 25.3.6.10636.altinitytest (altinity build)) 2025.07.28 12:00:44.690459 [ 3971 ] {} test_13.rmt2 (7f9b740d-015c-470e-8cc6-8ba33be0dc63): auto DB::StorageReplicatedMergeTree::processQueueEntry(ReplicatedMergeTreeQueue::SelectedEntryPtr)::(anonymous class)::operator()(LogEntryPtr &) const: Code: 86. DB::HTTPException: Received error from remote server http://146b4357c08d:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Ftest%2F01165%2Ftest_13%2Frmt%2Freplicas%2F1&part=20250728_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.6.10636.altinitytest (altinity build)) '. (RECEIVED_ERROR_FROM_REMOTE_IO_SERVER), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.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 const&, int&&, String const&, unsigned long&&, String const&) @ 0x000000000feda8d9 4. /build/src/IO/HTTPCommon.cpp:104: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x000000000feda6e2 5. /build/src/IO/HTTPCommon.cpp:93: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x000000000feda537 6. /build/src/IO/ReadWriteBufferFromHTTP.cpp:277: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x000000001184a4c4 7. /build/src/IO/ReadWriteBufferFromHTTP.cpp:285: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x000000001184a615 8. /build/src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x000000001184ae59 9. /build/src/IO/ReadWriteBufferFromHTTP.cpp:472: void std::__function::__policy_invoker::__call_impl[abi:se190107]>(std::__function::__policy_storage const*) @ 0x000000001184cedd 10. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001184858b 11. /build/src/IO/ReadWriteBufferFromHTTP.cpp:465: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x000000001184bf0b 12. /build/src/IO/ReadBuffer.h:60: DB::ReadBuffer::next() @ 0x000000000a148c7b 13. /build/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) @ 0x0000000011849fb2 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]>&)>&, 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&) @ 0x0000000011841980 15. /build/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) @ 0x000000001621208e 16. /build/src/Storages/StorageReplicatedMergeTree.cpp:5228: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl[abi:se190107] const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000015f9a5fe 17. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000015ed8bfd 18. /build/src/Storages/StorageReplicatedMergeTree.cpp:2514: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x0000000015ec9aab 19. /build/src/Storages/StorageReplicatedMergeTree.cpp:2349: DB::StorageReplicatedMergeTree::executeLogEntry(DB::ReplicatedMergeTreeLogEntry&) @ 0x0000000015eba91b 20. /build/src/Storages/StorageReplicatedMergeTree.cpp:3876: bool std::__function::__policy_invoker&)>::__call_impl[abi:se190107])::$_1, bool (std::shared_ptr&)>>(std::__function::__policy_storage const*, std::shared_ptr&) @ 0x0000000015f9837e 21. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000165d6fc3 22. /build/src/Storages/StorageReplicatedMergeTree.cpp:3872: DB::StorageReplicatedMergeTree::processQueueEntry(std::shared_ptr) @ 0x0000000015efc18a 23. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001624c1b2 24. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000162f9c70 25. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x00000000162fa55a 26. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc6653 27. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000000fccc4c3 28. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc3d92 29. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fcca080 30. ? @ 0x00007fbc6213eac3 31. ? @ 0x00007fbc621d0850 (version 25.3.6.10636.altinitytest (altinity build)) 2025.07.28 12:00:44.843211 [ 17255 ] {} 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. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception>&, String>(int, FormatStringHelperImpl>&>::type, std::type_identity::type>, std::basic_string_view>&, String&&) @ 0x000000001385a5eb 4. /build/src/Access/SettingsConstraints.cpp:376: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000013859b18 5. /build/src/Access/SettingsConstraints.cpp:300: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000013858faf 6. /build/src/Access/SettingsConstraints.cpp:209: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000013859223 7. /build/src/Interpreters/Context.cpp:2690: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000014436134 8. /build/src/Interpreters/Context.cpp:2729: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x000000001443662b 9. /build/src/Server/HTTPHandler.cpp:457: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000001686d165 10. /build/src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x0000000016870807 11. /build/src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x0000000016907e99 12. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 13. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 14. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 15. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 16. ? @ 0x00007fbc6213eac3 17. ? @ 0x00007fbc621d0850 (version 25.3.6.10636.altinitytest (altinity build)) 2025.07.28 12:00:45.148024 [ 3968 ] {} test_13.rmt2 (7f9b740d-015c-470e-8cc6-8ba33be0dc63): auto DB::StorageReplicatedMergeTree::processQueueEntry(ReplicatedMergeTreeQueue::SelectedEntryPtr)::(anonymous class)::operator()(LogEntryPtr &) const: Code: 86. DB::HTTPException: Received error from remote server http://146b4357c08d:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Ftest%2F01165%2Ftest_13%2Frmt%2Freplicas%2F1&part=20250728_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.6.10636.altinitytest (altinity build)) '. (RECEIVED_ERROR_FROM_REMOTE_IO_SERVER), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.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 const&, int&&, String const&, unsigned long&&, String const&) @ 0x000000000feda8d9 4. /build/src/IO/HTTPCommon.cpp:104: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x000000000feda6e2 5. /build/src/IO/HTTPCommon.cpp:93: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x000000000feda537 6. /build/src/IO/ReadWriteBufferFromHTTP.cpp:277: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x000000001184a4c4 7. /build/src/IO/ReadWriteBufferFromHTTP.cpp:285: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x000000001184a615 8. /build/src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x000000001184ae59 9. /build/src/IO/ReadWriteBufferFromHTTP.cpp:472: void std::__function::__policy_invoker::__call_impl[abi:se190107]>(std::__function::__policy_storage const*) @ 0x000000001184cedd 10. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001184858b 11. /build/src/IO/ReadWriteBufferFromHTTP.cpp:465: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x000000001184bf0b 12. /build/src/IO/ReadBuffer.h:60: DB::ReadBuffer::next() @ 0x000000000a148c7b 13. /build/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) @ 0x0000000011849fb2 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]>&)>&, 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&) @ 0x0000000011841980 15. /build/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) @ 0x000000001621208e 16. /build/src/Storages/StorageReplicatedMergeTree.cpp:5228: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl[abi:se190107] const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000015f9a5fe 17. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000015ed8bfd 18. /build/src/Storages/StorageReplicatedMergeTree.cpp:2514: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x0000000015ec9aab 19. /build/src/Storages/StorageReplicatedMergeTree.cpp:2349: DB::StorageReplicatedMergeTree::executeLogEntry(DB::ReplicatedMergeTreeLogEntry&) @ 0x0000000015eba91b 20. /build/src/Storages/StorageReplicatedMergeTree.cpp:3876: bool std::__function::__policy_invoker&)>::__call_impl[abi:se190107])::$_1, bool (std::shared_ptr&)>>(std::__function::__policy_storage const*, std::shared_ptr&) @ 0x0000000015f9837e 21. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000165d6fc3 22. /build/src/Storages/StorageReplicatedMergeTree.cpp:3872: DB::StorageReplicatedMergeTree::processQueueEntry(std::shared_ptr) @ 0x0000000015efc18a 23. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001624c1b2 24. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000162f9c70 25. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x00000000162fa55a 26. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc6653 27. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000000fccc4c3 28. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc3d92 29. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fcca080 30. ? @ 0x00007fbc6213eac3 31. ? @ 0x00007fbc621d0850 (version 25.3.6.10636.altinitytest (altinity build)) 2025.07.28 12:00:46.258643 [ 3972 ] {} test_13.rmt2 (7f9b740d-015c-470e-8cc6-8ba33be0dc63): auto DB::StorageReplicatedMergeTree::processQueueEntry(ReplicatedMergeTreeQueue::SelectedEntryPtr)::(anonymous class)::operator()(LogEntryPtr &) const: Code: 86. DB::HTTPException: Received error from remote server http://146b4357c08d:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Ftest%2F01165%2Ftest_13%2Frmt%2Freplicas%2F1&part=20250728_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.6.10636.altinitytest (altinity build)) '. (RECEIVED_ERROR_FROM_REMOTE_IO_SERVER), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.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 const&, int&&, String const&, unsigned long&&, String const&) @ 0x000000000feda8d9 4. /build/src/IO/HTTPCommon.cpp:104: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x000000000feda6e2 5. /build/src/IO/HTTPCommon.cpp:93: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x000000000feda537 6. /build/src/IO/ReadWriteBufferFromHTTP.cpp:277: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x000000001184a4c4 7. /build/src/IO/ReadWriteBufferFromHTTP.cpp:285: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x000000001184a615 8. /build/src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x000000001184ae59 9. /build/src/IO/ReadWriteBufferFromHTTP.cpp:472: void std::__function::__policy_invoker::__call_impl[abi:se190107]>(std::__function::__policy_storage const*) @ 0x000000001184cedd 10. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001184858b 11. /build/src/IO/ReadWriteBufferFromHTTP.cpp:465: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x000000001184bf0b 12. /build/src/IO/ReadBuffer.h:60: DB::ReadBuffer::next() @ 0x000000000a148c7b 13. /build/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) @ 0x0000000011849fb2 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]>&)>&, 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&) @ 0x0000000011841980 15. /build/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) @ 0x000000001621208e 16. /build/src/Storages/StorageReplicatedMergeTree.cpp:5228: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl[abi:se190107] const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000015f9a5fe 17. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000015ed8bfd 18. /build/src/Storages/StorageReplicatedMergeTree.cpp:2514: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x0000000015ec9aab 19. /build/src/Storages/StorageReplicatedMergeTree.cpp:2349: DB::StorageReplicatedMergeTree::executeLogEntry(DB::ReplicatedMergeTreeLogEntry&) @ 0x0000000015eba91b 20. /build/src/Storages/StorageReplicatedMergeTree.cpp:3876: bool std::__function::__policy_invoker&)>::__call_impl[abi:se190107])::$_1, bool (std::shared_ptr&)>>(std::__function::__policy_storage const*, std::shared_ptr&) @ 0x0000000015f9837e 21. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000165d6fc3 22. /build/src/Storages/StorageReplicatedMergeTree.cpp:3872: DB::StorageReplicatedMergeTree::processQueueEntry(std::shared_ptr) @ 0x0000000015efc18a 23. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001624c1b2 24. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000162f9c70 25. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x00000000162fa55a 26. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc6653 27. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000000fccc4c3 28. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc3d92 29. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fcca080 30. ? @ 0x00007fbc6213eac3 31. ? @ 0x00007fbc621d0850 (version 25.3.6.10636.altinitytest (altinity build)) 2025.07.28 12:00:46.741353 [ 3962 ] {} test_13.rmt2 (7f9b740d-015c-470e-8cc6-8ba33be0dc63): auto DB::StorageReplicatedMergeTree::processQueueEntry(ReplicatedMergeTreeQueue::SelectedEntryPtr)::(anonymous class)::operator()(LogEntryPtr &) const: Code: 86. DB::HTTPException: Received error from remote server http://146b4357c08d:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Ftest%2F01165%2Ftest_13%2Frmt%2Freplicas%2F1&part=20250728_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.6.10636.altinitytest (altinity build)) '. (RECEIVED_ERROR_FROM_REMOTE_IO_SERVER), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.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 const&, int&&, String const&, unsigned long&&, String const&) @ 0x000000000feda8d9 4. /build/src/IO/HTTPCommon.cpp:104: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x000000000feda6e2 5. /build/src/IO/HTTPCommon.cpp:93: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x000000000feda537 6. /build/src/IO/ReadWriteBufferFromHTTP.cpp:277: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x000000001184a4c4 7. /build/src/IO/ReadWriteBufferFromHTTP.cpp:285: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x000000001184a615 8. /build/src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x000000001184ae59 9. /build/src/IO/ReadWriteBufferFromHTTP.cpp:472: void std::__function::__policy_invoker::__call_impl[abi:se190107]>(std::__function::__policy_storage const*) @ 0x000000001184cedd 10. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001184858b 11. /build/src/IO/ReadWriteBufferFromHTTP.cpp:465: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x000000001184bf0b 12. /build/src/IO/ReadBuffer.h:60: DB::ReadBuffer::next() @ 0x000000000a148c7b 13. /build/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) @ 0x0000000011849fb2 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]>&)>&, 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&) @ 0x0000000011841980 15. /build/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) @ 0x000000001621208e 16. /build/src/Storages/StorageReplicatedMergeTree.cpp:5228: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl[abi:se190107] const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000015f9a5fe 17. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000015ed8bfd 18. /build/src/Storages/StorageReplicatedMergeTree.cpp:2514: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x0000000015ec9aab 19. /build/src/Storages/StorageReplicatedMergeTree.cpp:2349: DB::StorageReplicatedMergeTree::executeLogEntry(DB::ReplicatedMergeTreeLogEntry&) @ 0x0000000015eba91b 20. /build/src/Storages/StorageReplicatedMergeTree.cpp:3876: bool std::__function::__policy_invoker&)>::__call_impl[abi:se190107])::$_1, bool (std::shared_ptr&)>>(std::__function::__policy_storage const*, std::shared_ptr&) @ 0x0000000015f9837e 21. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000165d6fc3 22. /build/src/Storages/StorageReplicatedMergeTree.cpp:3872: DB::StorageReplicatedMergeTree::processQueueEntry(std::shared_ptr) @ 0x0000000015efc18a 23. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001624c1b2 24. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000162f9c70 25. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x00000000162fa55a 26. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc6653 27. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000000fccc4c3 28. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc3d92 29. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fcca080 30. ? @ 0x00007fbc6213eac3 31. ? @ 0x00007fbc621d0850 (version 25.3.6.10636.altinitytest (altinity build)) 2025.07.28 12:00:46.882262 [ 3968 ] {} test_13.rmt2 (7f9b740d-015c-470e-8cc6-8ba33be0dc63): auto DB::StorageReplicatedMergeTree::processQueueEntry(ReplicatedMergeTreeQueue::SelectedEntryPtr)::(anonymous class)::operator()(LogEntryPtr &) const: Code: 86. DB::HTTPException: Received error from remote server http://146b4357c08d:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Ftest%2F01165%2Ftest_13%2Frmt%2Freplicas%2F1&part=20250728_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.6.10636.altinitytest (altinity build)) '. (RECEIVED_ERROR_FROM_REMOTE_IO_SERVER), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.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 const&, int&&, String const&, unsigned long&&, String const&) @ 0x000000000feda8d9 4. /build/src/IO/HTTPCommon.cpp:104: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x000000000feda6e2 5. /build/src/IO/HTTPCommon.cpp:93: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x000000000feda537 6. /build/src/IO/ReadWriteBufferFromHTTP.cpp:277: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x000000001184a4c4 7. /build/src/IO/ReadWriteBufferFromHTTP.cpp:285: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x000000001184a615 8. /build/src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x000000001184ae59 9. /build/src/IO/ReadWriteBufferFromHTTP.cpp:472: void std::__function::__policy_invoker::__call_impl[abi:se190107]>(std::__function::__policy_storage const*) @ 0x000000001184cedd 10. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001184858b 11. /build/src/IO/ReadWriteBufferFromHTTP.cpp:465: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x000000001184bf0b 12. /build/src/IO/ReadBuffer.h:60: DB::ReadBuffer::next() @ 0x000000000a148c7b 13. /build/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) @ 0x0000000011849fb2 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]>&)>&, 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&) @ 0x0000000011841980 15. /build/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) @ 0x000000001621208e 16. /build/src/Storages/StorageReplicatedMergeTree.cpp:5228: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl[abi:se190107] const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000015f9a5fe 17. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000015ed8bfd 18. /build/src/Storages/StorageReplicatedMergeTree.cpp:2514: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x0000000015ec9aab 19. /build/src/Storages/StorageReplicatedMergeTree.cpp:2349: DB::StorageReplicatedMergeTree::executeLogEntry(DB::ReplicatedMergeTreeLogEntry&) @ 0x0000000015eba91b 20. /build/src/Storages/StorageReplicatedMergeTree.cpp:3876: bool std::__function::__policy_invoker&)>::__call_impl[abi:se190107])::$_1, bool (std::shared_ptr&)>>(std::__function::__policy_storage const*, std::shared_ptr&) @ 0x0000000015f9837e 21. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000165d6fc3 22. /build/src/Storages/StorageReplicatedMergeTree.cpp:3872: DB::StorageReplicatedMergeTree::processQueueEntry(std::shared_ptr) @ 0x0000000015efc18a 23. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001624c1b2 24. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000162f9c70 25. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x00000000162fa55a 26. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc6653 27. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000000fccc4c3 28. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc3d92 29. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fcca080 30. ? @ 0x00007fbc6213eac3 31. ? @ 0x00007fbc621d0850 (version 25.3.6.10636.altinitytest (altinity build)) 2025.07.28 12:00:47.256052 [ 3977 ] {} test_13.rmt2 (7f9b740d-015c-470e-8cc6-8ba33be0dc63): auto DB::StorageReplicatedMergeTree::processQueueEntry(ReplicatedMergeTreeQueue::SelectedEntryPtr)::(anonymous class)::operator()(LogEntryPtr &) const: Code: 86. DB::HTTPException: Received error from remote server http://146b4357c08d:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Ftest%2F01165%2Ftest_13%2Frmt%2Freplicas%2F1&part=20250728_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.6.10636.altinitytest (altinity build)) '. (RECEIVED_ERROR_FROM_REMOTE_IO_SERVER), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.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 const&, int&&, String const&, unsigned long&&, String const&) @ 0x000000000feda8d9 4. /build/src/IO/HTTPCommon.cpp:104: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x000000000feda6e2 5. /build/src/IO/HTTPCommon.cpp:93: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x000000000feda537 6. /build/src/IO/ReadWriteBufferFromHTTP.cpp:277: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x000000001184a4c4 7. /build/src/IO/ReadWriteBufferFromHTTP.cpp:285: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x000000001184a615 8. /build/src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x000000001184ae59 9. /build/src/IO/ReadWriteBufferFromHTTP.cpp:472: void std::__function::__policy_invoker::__call_impl[abi:se190107]>(std::__function::__policy_storage const*) @ 0x000000001184cedd 10. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001184858b 11. /build/src/IO/ReadWriteBufferFromHTTP.cpp:465: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x000000001184bf0b 12. /build/src/IO/ReadBuffer.h:60: DB::ReadBuffer::next() @ 0x000000000a148c7b 13. /build/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) @ 0x0000000011849fb2 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]>&)>&, 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&) @ 0x0000000011841980 15. /build/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) @ 0x000000001621208e 16. /build/src/Storages/StorageReplicatedMergeTree.cpp:5228: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl[abi:se190107] const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000015f9a5fe 17. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000015ed8bfd 18. /build/src/Storages/StorageReplicatedMergeTree.cpp:2514: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x0000000015ec9aab 19. /build/src/Storages/StorageReplicatedMergeTree.cpp:2349: DB::StorageReplicatedMergeTree::executeLogEntry(DB::ReplicatedMergeTreeLogEntry&) @ 0x0000000015eba91b 20. /build/src/Storages/StorageReplicatedMergeTree.cpp:3876: bool std::__function::__policy_invoker&)>::__call_impl[abi:se190107])::$_1, bool (std::shared_ptr&)>>(std::__function::__policy_storage const*, std::shared_ptr&) @ 0x0000000015f9837e 21. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000165d6fc3 22. /build/src/Storages/StorageReplicatedMergeTree.cpp:3872: DB::StorageReplicatedMergeTree::processQueueEntry(std::shared_ptr) @ 0x0000000015efc18a 23. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001624c1b2 24. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000162f9c70 25. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x00000000162fa55a 26. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc6653 27. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000000fccc4c3 28. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc3d92 29. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fcca080 30. ? @ 0x00007fbc6213eac3 31. ? @ 0x00007fbc621d0850 (version 25.3.6.10636.altinitytest (altinity build)) 2025.07.28 12:00:47.740879 [ 3967 ] {} test_13.rmt2 (7f9b740d-015c-470e-8cc6-8ba33be0dc63): auto DB::StorageReplicatedMergeTree::processQueueEntry(ReplicatedMergeTreeQueue::SelectedEntryPtr)::(anonymous class)::operator()(LogEntryPtr &) const: Code: 86. DB::HTTPException: Received error from remote server http://146b4357c08d:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Ftest%2F01165%2Ftest_13%2Frmt%2Freplicas%2F1&part=20250728_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.6.10636.altinitytest (altinity build)) '. (RECEIVED_ERROR_FROM_REMOTE_IO_SERVER), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.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 const&, int&&, String const&, unsigned long&&, String const&) @ 0x000000000feda8d9 4. /build/src/IO/HTTPCommon.cpp:104: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x000000000feda6e2 5. /build/src/IO/HTTPCommon.cpp:93: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x000000000feda537 6. /build/src/IO/ReadWriteBufferFromHTTP.cpp:277: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x000000001184a4c4 7. /build/src/IO/ReadWriteBufferFromHTTP.cpp:285: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x000000001184a615 8. /build/src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x000000001184ae59 9. /build/src/IO/ReadWriteBufferFromHTTP.cpp:472: void std::__function::__policy_invoker::__call_impl[abi:se190107]>(std::__function::__policy_storage const*) @ 0x000000001184cedd 10. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001184858b 11. /build/src/IO/ReadWriteBufferFromHTTP.cpp:465: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x000000001184bf0b 12. /build/src/IO/ReadBuffer.h:60: DB::ReadBuffer::next() @ 0x000000000a148c7b 13. /build/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) @ 0x0000000011849fb2 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]>&)>&, 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&) @ 0x0000000011841980 15. /build/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) @ 0x000000001621208e 16. /build/src/Storages/StorageReplicatedMergeTree.cpp:5228: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl[abi:se190107] const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000015f9a5fe 17. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000015ed8bfd 18. /build/src/Storages/StorageReplicatedMergeTree.cpp:2514: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x0000000015ec9aab 19. /build/src/Storages/StorageReplicatedMergeTree.cpp:2349: DB::StorageReplicatedMergeTree::executeLogEntry(DB::ReplicatedMergeTreeLogEntry&) @ 0x0000000015eba91b 20. /build/src/Storages/StorageReplicatedMergeTree.cpp:3876: bool std::__function::__policy_invoker&)>::__call_impl[abi:se190107])::$_1, bool (std::shared_ptr&)>>(std::__function::__policy_storage const*, std::shared_ptr&) @ 0x0000000015f9837e 21. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000165d6fc3 22. /build/src/Storages/StorageReplicatedMergeTree.cpp:3872: DB::StorageReplicatedMergeTree::processQueueEntry(std::shared_ptr) @ 0x0000000015efc18a 23. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001624c1b2 24. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000162f9c70 25. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x00000000162fa55a 26. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc6653 27. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000000fccc4c3 28. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc3d92 29. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fcca080 30. ? @ 0x00007fbc6213eac3 31. ? @ 0x00007fbc621d0850 (version 25.3.6.10636.altinitytest (altinity build)) 2025.07.28 12:00:48.624112 [ 3960 ] {} test_13.rmt2 (7f9b740d-015c-470e-8cc6-8ba33be0dc63): auto DB::StorageReplicatedMergeTree::processQueueEntry(ReplicatedMergeTreeQueue::SelectedEntryPtr)::(anonymous class)::operator()(LogEntryPtr &) const: Code: 86. DB::HTTPException: Received error from remote server http://146b4357c08d:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Ftest%2F01165%2Ftest_13%2Frmt%2Freplicas%2F1&part=20250728_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.6.10636.altinitytest (altinity build)) '. (RECEIVED_ERROR_FROM_REMOTE_IO_SERVER), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.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 const&, int&&, String const&, unsigned long&&, String const&) @ 0x000000000feda8d9 4. /build/src/IO/HTTPCommon.cpp:104: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x000000000feda6e2 5. /build/src/IO/HTTPCommon.cpp:93: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x000000000feda537 6. /build/src/IO/ReadWriteBufferFromHTTP.cpp:277: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x000000001184a4c4 7. /build/src/IO/ReadWriteBufferFromHTTP.cpp:285: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x000000001184a615 8. /build/src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x000000001184ae59 9. /build/src/IO/ReadWriteBufferFromHTTP.cpp:472: void std::__function::__policy_invoker::__call_impl[abi:se190107]>(std::__function::__policy_storage const*) @ 0x000000001184cedd 10. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001184858b 11. /build/src/IO/ReadWriteBufferFromHTTP.cpp:465: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x000000001184bf0b 12. /build/src/IO/ReadBuffer.h:60: DB::ReadBuffer::next() @ 0x000000000a148c7b 13. /build/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) @ 0x0000000011849fb2 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]>&)>&, 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&) @ 0x0000000011841980 15. /build/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) @ 0x000000001621208e 16. /build/src/Storages/StorageReplicatedMergeTree.cpp:5228: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl[abi:se190107] const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000015f9a5fe 17. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000015ed8bfd 18. /build/src/Storages/StorageReplicatedMergeTree.cpp:2514: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x0000000015ec9aab 19. /build/src/Storages/StorageReplicatedMergeTree.cpp:2349: DB::StorageReplicatedMergeTree::executeLogEntry(DB::ReplicatedMergeTreeLogEntry&) @ 0x0000000015eba91b 20. /build/src/Storages/StorageReplicatedMergeTree.cpp:3876: bool std::__function::__policy_invoker&)>::__call_impl[abi:se190107])::$_1, bool (std::shared_ptr&)>>(std::__function::__policy_storage const*, std::shared_ptr&) @ 0x0000000015f9837e 21. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000165d6fc3 22. /build/src/Storages/StorageReplicatedMergeTree.cpp:3872: DB::StorageReplicatedMergeTree::processQueueEntry(std::shared_ptr) @ 0x0000000015efc18a 23. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001624c1b2 24. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000162f9c70 25. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x00000000162fa55a 26. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc6653 27. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000000fccc4c3 28. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc3d92 29. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fcca080 30. ? @ 0x00007fbc6213eac3 31. ? @ 0x00007fbc621d0850 (version 25.3.6.10636.altinitytest (altinity build)) 2025.07.28 12:00:49.312845 [ 3970 ] {} test_13.rmt2 (7f9b740d-015c-470e-8cc6-8ba33be0dc63): auto DB::StorageReplicatedMergeTree::processQueueEntry(ReplicatedMergeTreeQueue::SelectedEntryPtr)::(anonymous class)::operator()(LogEntryPtr &) const: Code: 86. DB::HTTPException: Received error from remote server http://146b4357c08d:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Ftest%2F01165%2Ftest_13%2Frmt%2Freplicas%2F1&part=20250728_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.6.10636.altinitytest (altinity build)) '. (RECEIVED_ERROR_FROM_REMOTE_IO_SERVER), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.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 const&, int&&, String const&, unsigned long&&, String const&) @ 0x000000000feda8d9 4. /build/src/IO/HTTPCommon.cpp:104: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x000000000feda6e2 5. /build/src/IO/HTTPCommon.cpp:93: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x000000000feda537 6. /build/src/IO/ReadWriteBufferFromHTTP.cpp:277: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x000000001184a4c4 7. /build/src/IO/ReadWriteBufferFromHTTP.cpp:285: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x000000001184a615 8. /build/src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x000000001184ae59 9. /build/src/IO/ReadWriteBufferFromHTTP.cpp:472: void std::__function::__policy_invoker::__call_impl[abi:se190107]>(std::__function::__policy_storage const*) @ 0x000000001184cedd 10. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001184858b 11. /build/src/IO/ReadWriteBufferFromHTTP.cpp:465: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x000000001184bf0b 12. /build/src/IO/ReadBuffer.h:60: DB::ReadBuffer::next() @ 0x000000000a148c7b 13. /build/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) @ 0x0000000011849fb2 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]>&)>&, 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&) @ 0x0000000011841980 15. /build/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) @ 0x000000001621208e 16. /build/src/Storages/StorageReplicatedMergeTree.cpp:5228: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl[abi:se190107] const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000015f9a5fe 17. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000015ed8bfd 18. /build/src/Storages/StorageReplicatedMergeTree.cpp:2514: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x0000000015ec9aab 19. /build/src/Storages/StorageReplicatedMergeTree.cpp:2349: DB::StorageReplicatedMergeTree::executeLogEntry(DB::ReplicatedMergeTreeLogEntry&) @ 0x0000000015eba91b 20. /build/src/Storages/StorageReplicatedMergeTree.cpp:3876: bool std::__function::__policy_invoker&)>::__call_impl[abi:se190107])::$_1, bool (std::shared_ptr&)>>(std::__function::__policy_storage const*, std::shared_ptr&) @ 0x0000000015f9837e 21. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000165d6fc3 22. /build/src/Storages/StorageReplicatedMergeTree.cpp:3872: DB::StorageReplicatedMergeTree::processQueueEntry(std::shared_ptr) @ 0x0000000015efc18a 23. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001624c1b2 24. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000162f9c70 25. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x00000000162fa55a 26. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc6653 27. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000000fccc4c3 28. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc3d92 29. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fcca080 30. ? @ 0x00007fbc6213eac3 31. ? @ 0x00007fbc621d0850 (version 25.3.6.10636.altinitytest (altinity build)) 2025.07.28 12:00:50.030347 [ 3961 ] {} test_13.rmt2 (7f9b740d-015c-470e-8cc6-8ba33be0dc63): auto DB::StorageReplicatedMergeTree::processQueueEntry(ReplicatedMergeTreeQueue::SelectedEntryPtr)::(anonymous class)::operator()(LogEntryPtr &) const: Code: 86. DB::HTTPException: Received error from remote server http://146b4357c08d:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Ftest%2F01165%2Ftest_13%2Frmt%2Freplicas%2F1&part=20250728_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.6.10636.altinitytest (altinity build)) '. (RECEIVED_ERROR_FROM_REMOTE_IO_SERVER), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.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 const&, int&&, String const&, unsigned long&&, String const&) @ 0x000000000feda8d9 4. /build/src/IO/HTTPCommon.cpp:104: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x000000000feda6e2 5. /build/src/IO/HTTPCommon.cpp:93: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x000000000feda537 6. /build/src/IO/ReadWriteBufferFromHTTP.cpp:277: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x000000001184a4c4 7. /build/src/IO/ReadWriteBufferFromHTTP.cpp:285: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x000000001184a615 8. /build/src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x000000001184ae59 9. /build/src/IO/ReadWriteBufferFromHTTP.cpp:472: void std::__function::__policy_invoker::__call_impl[abi:se190107]>(std::__function::__policy_storage const*) @ 0x000000001184cedd 10. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001184858b 11. /build/src/IO/ReadWriteBufferFromHTTP.cpp:465: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x000000001184bf0b 12. /build/src/IO/ReadBuffer.h:60: DB::ReadBuffer::next() @ 0x000000000a148c7b 13. /build/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) @ 0x0000000011849fb2 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]>&)>&, 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&) @ 0x0000000011841980 15. /build/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) @ 0x000000001621208e 16. /build/src/Storages/StorageReplicatedMergeTree.cpp:5228: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl[abi:se190107] const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000015f9a5fe 17. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000015ed8bfd 18. /build/src/Storages/StorageReplicatedMergeTree.cpp:2514: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x0000000015ec9aab 19. /build/src/Storages/StorageReplicatedMergeTree.cpp:2349: DB::StorageReplicatedMergeTree::executeLogEntry(DB::ReplicatedMergeTreeLogEntry&) @ 0x0000000015eba91b 20. /build/src/Storages/StorageReplicatedMergeTree.cpp:3876: bool std::__function::__policy_invoker&)>::__call_impl[abi:se190107])::$_1, bool (std::shared_ptr&)>>(std::__function::__policy_storage const*, std::shared_ptr&) @ 0x0000000015f9837e 21. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000165d6fc3 22. /build/src/Storages/StorageReplicatedMergeTree.cpp:3872: DB::StorageReplicatedMergeTree::processQueueEntry(std::shared_ptr) @ 0x0000000015efc18a 23. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001624c1b2 24. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000162f9c70 25. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x00000000162fa55a 26. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc6653 27. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000000fccc4c3 28. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc3d92 29. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fcca080 30. ? @ 0x00007fbc6213eac3 31. ? @ 0x00007fbc621d0850 (version 25.3.6.10636.altinitytest (altinity build)) 2025.07.28 12:00:50.910137 [ 3963 ] {} test_13.rmt2 (7f9b740d-015c-470e-8cc6-8ba33be0dc63): auto DB::StorageReplicatedMergeTree::processQueueEntry(ReplicatedMergeTreeQueue::SelectedEntryPtr)::(anonymous class)::operator()(LogEntryPtr &) const: Code: 86. DB::HTTPException: Received error from remote server http://146b4357c08d:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Ftest%2F01165%2Ftest_13%2Frmt%2Freplicas%2F1&part=20250728_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.6.10636.altinitytest (altinity build)) '. (RECEIVED_ERROR_FROM_REMOTE_IO_SERVER), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.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 const&, int&&, String const&, unsigned long&&, String const&) @ 0x000000000feda8d9 4. /build/src/IO/HTTPCommon.cpp:104: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x000000000feda6e2 5. /build/src/IO/HTTPCommon.cpp:93: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x000000000feda537 6. /build/src/IO/ReadWriteBufferFromHTTP.cpp:277: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x000000001184a4c4 7. /build/src/IO/ReadWriteBufferFromHTTP.cpp:285: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x000000001184a615 8. /build/src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x000000001184ae59 9. /build/src/IO/ReadWriteBufferFromHTTP.cpp:472: void std::__function::__policy_invoker::__call_impl[abi:se190107]>(std::__function::__policy_storage const*) @ 0x000000001184cedd 10. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001184858b 11. /build/src/IO/ReadWriteBufferFromHTTP.cpp:465: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x000000001184bf0b 12. /build/src/IO/ReadBuffer.h:60: DB::ReadBuffer::next() @ 0x000000000a148c7b 13. /build/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) @ 0x0000000011849fb2 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]>&)>&, 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&) @ 0x0000000011841980 15. /build/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) @ 0x000000001621208e 16. /build/src/Storages/StorageReplicatedMergeTree.cpp:5228: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl[abi:se190107] const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000015f9a5fe 17. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000015ed8bfd 18. /build/src/Storages/StorageReplicatedMergeTree.cpp:2514: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x0000000015ec9aab 19. /build/src/Storages/StorageReplicatedMergeTree.cpp:2349: DB::StorageReplicatedMergeTree::executeLogEntry(DB::ReplicatedMergeTreeLogEntry&) @ 0x0000000015eba91b 20. /build/src/Storages/StorageReplicatedMergeTree.cpp:3876: bool std::__function::__policy_invoker&)>::__call_impl[abi:se190107])::$_1, bool (std::shared_ptr&)>>(std::__function::__policy_storage const*, std::shared_ptr&) @ 0x0000000015f9837e 21. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000165d6fc3 22. /build/src/Storages/StorageReplicatedMergeTree.cpp:3872: DB::StorageReplicatedMergeTree::processQueueEntry(std::shared_ptr) @ 0x0000000015efc18a 23. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001624c1b2 24. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000162f9c70 25. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x00000000162fa55a 26. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc6653 27. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000000fccc4c3 28. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc3d92 29. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fcca080 30. ? @ 0x00007fbc6213eac3 31. ? @ 0x00007fbc621d0850 (version 25.3.6.10636.altinitytest (altinity build)) 2025.07.28 12:00:51.218202 [ 3971 ] {} test_13.rmt2 (7f9b740d-015c-470e-8cc6-8ba33be0dc63): auto DB::StorageReplicatedMergeTree::processQueueEntry(ReplicatedMergeTreeQueue::SelectedEntryPtr)::(anonymous class)::operator()(LogEntryPtr &) const: Code: 86. DB::HTTPException: Received error from remote server http://146b4357c08d:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Ftest%2F01165%2Ftest_13%2Frmt%2Freplicas%2F1&part=20250728_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.6.10636.altinitytest (altinity build)) '. (RECEIVED_ERROR_FROM_REMOTE_IO_SERVER), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.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 const&, int&&, String const&, unsigned long&&, String const&) @ 0x000000000feda8d9 4. /build/src/IO/HTTPCommon.cpp:104: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x000000000feda6e2 5. /build/src/IO/HTTPCommon.cpp:93: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x000000000feda537 6. /build/src/IO/ReadWriteBufferFromHTTP.cpp:277: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x000000001184a4c4 7. /build/src/IO/ReadWriteBufferFromHTTP.cpp:285: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x000000001184a615 8. /build/src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x000000001184ae59 9. /build/src/IO/ReadWriteBufferFromHTTP.cpp:472: void std::__function::__policy_invoker::__call_impl[abi:se190107]>(std::__function::__policy_storage const*) @ 0x000000001184cedd 10. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001184858b 11. /build/src/IO/ReadWriteBufferFromHTTP.cpp:465: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x000000001184bf0b 12. /build/src/IO/ReadBuffer.h:60: DB::ReadBuffer::next() @ 0x000000000a148c7b 13. /build/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) @ 0x0000000011849fb2 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]>&)>&, 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&) @ 0x0000000011841980 15. /build/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) @ 0x000000001621208e 16. /build/src/Storages/StorageReplicatedMergeTree.cpp:5228: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl[abi:se190107] const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000015f9a5fe 17. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000015ed8bfd 18. /build/src/Storages/StorageReplicatedMergeTree.cpp:2514: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x0000000015ec9aab 19. /build/src/Storages/StorageReplicatedMergeTree.cpp:2349: DB::StorageReplicatedMergeTree::executeLogEntry(DB::ReplicatedMergeTreeLogEntry&) @ 0x0000000015eba91b 20. /build/src/Storages/StorageReplicatedMergeTree.cpp:3876: bool std::__function::__policy_invoker&)>::__call_impl[abi:se190107])::$_1, bool (std::shared_ptr&)>>(std::__function::__policy_storage const*, std::shared_ptr&) @ 0x0000000015f9837e 21. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000165d6fc3 22. /build/src/Storages/StorageReplicatedMergeTree.cpp:3872: DB::StorageReplicatedMergeTree::processQueueEntry(std::shared_ptr) @ 0x0000000015efc18a 23. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001624c1b2 24. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000162f9c70 25. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x00000000162fa55a 26. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc6653 27. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000000fccc4c3 28. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc3d92 29. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fcca080 30. ? @ 0x00007fbc6213eac3 31. ? @ 0x00007fbc621d0850 (version 25.3.6.10636.altinitytest (altinity build)) 2025.07.28 12:00:52.007393 [ 17371 ] {ac1c0a0e-9b28-489c-8f6d-08780c9f40b9} 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.6.10636.altinitytest (altinity build)) (from [::1]:55028) (comment: 01412_row_from_totals.sql) (query 9, line 13) (in query: SELECT EventDate FROM ( SELECT EventDate FROM tracking_events_tmp AS t1 WHERE (EventDate >= toDate('2020-07-10')) AND (EventDate <= toDate('2020-07-11')) AND (APIKey = 2) GROUP BY EventDate ) FULL OUTER JOIN ( SELECT EventDate FROM remote('127.0.0.{1,3}', currentDatabase(), open_events_tmp) AS t2 WHERE (EventDate >= toDate('2020-07-10')) AND (EventDate <= toDate('2020-07-11')) AND (APIKey = 2) GROUP BY EventDate WITH TOTALS ) USING EventDate ORDER BY EventDate settings totals_mode = 'after_having_auto', group_by_overflow_mode = 'any', max_rows_to_group_by = 10000000, joined_subquery_requires_alias=0;), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000000a074fcb 4. /build/src/Interpreters/executeQuery.cpp:1338: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c8a380 5. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 6. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 7. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 8. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 9. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 10. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 11. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 12. ? @ 0x00007fbc6213eac3 13. ? @ 0x00007fbc621d0850 2025.07.28 12:00:52.024840 [ 17371 ] {} 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. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000000a074fcb 4. /build/src/Interpreters/executeQuery.cpp:1338: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c8a380 5. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 6. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 7. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 8. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 9. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 10. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 11. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 12. ? @ 0x00007fbc6213eac3 13. ? @ 0x00007fbc621d0850 2025.07.28 12:00:52.317709 [ 3972 ] {} test_13.rmt2 (7f9b740d-015c-470e-8cc6-8ba33be0dc63): auto DB::StorageReplicatedMergeTree::processQueueEntry(ReplicatedMergeTreeQueue::SelectedEntryPtr)::(anonymous class)::operator()(LogEntryPtr &) const: Code: 86. DB::HTTPException: Received error from remote server http://146b4357c08d:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Ftest%2F01165%2Ftest_13%2Frmt%2Freplicas%2F1&part=20250728_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.6.10636.altinitytest (altinity build)) '. (RECEIVED_ERROR_FROM_REMOTE_IO_SERVER), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.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 const&, int&&, String const&, unsigned long&&, String const&) @ 0x000000000feda8d9 4. /build/src/IO/HTTPCommon.cpp:104: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x000000000feda6e2 5. /build/src/IO/HTTPCommon.cpp:93: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x000000000feda537 6. /build/src/IO/ReadWriteBufferFromHTTP.cpp:277: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x000000001184a4c4 7. /build/src/IO/ReadWriteBufferFromHTTP.cpp:285: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x000000001184a615 8. /build/src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x000000001184ae59 9. /build/src/IO/ReadWriteBufferFromHTTP.cpp:472: void std::__function::__policy_invoker::__call_impl[abi:se190107]>(std::__function::__policy_storage const*) @ 0x000000001184cedd 10. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001184858b 11. /build/src/IO/ReadWriteBufferFromHTTP.cpp:465: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x000000001184bf0b 12. /build/src/IO/ReadBuffer.h:60: DB::ReadBuffer::next() @ 0x000000000a148c7b 13. /build/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) @ 0x0000000011849fb2 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]>&)>&, 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&) @ 0x0000000011841980 15. /build/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) @ 0x000000001621208e 16. /build/src/Storages/StorageReplicatedMergeTree.cpp:5228: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl[abi:se190107] const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000015f9a5fe 17. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000015ed8bfd 18. /build/src/Storages/StorageReplicatedMergeTree.cpp:2514: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x0000000015ec9aab 19. /build/src/Storages/StorageReplicatedMergeTree.cpp:2349: DB::StorageReplicatedMergeTree::executeLogEntry(DB::ReplicatedMergeTreeLogEntry&) @ 0x0000000015eba91b 20. /build/src/Storages/StorageReplicatedMergeTree.cpp:3876: bool std::__function::__policy_invoker&)>::__call_impl[abi:se190107])::$_1, bool (std::shared_ptr&)>>(std::__function::__policy_storage const*, std::shared_ptr&) @ 0x0000000015f9837e 21. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000165d6fc3 22. /build/src/Storages/StorageReplicatedMergeTree.cpp:3872: DB::StorageReplicatedMergeTree::processQueueEntry(std::shared_ptr) @ 0x0000000015efc18a 23. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001624c1b2 24. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000162f9c70 25. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x00000000162fa55a 26. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc6653 27. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000000fccc4c3 28. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc3d92 29. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fcca080 30. ? @ 0x00007fbc6213eac3 31. ? @ 0x00007fbc621d0850 (version 25.3.6.10636.altinitytest (altinity build)) 2025.07.28 12:00:52.995284 [ 3965 ] {} test_13.rmt2 (7f9b740d-015c-470e-8cc6-8ba33be0dc63): auto DB::StorageReplicatedMergeTree::processQueueEntry(ReplicatedMergeTreeQueue::SelectedEntryPtr)::(anonymous class)::operator()(LogEntryPtr &) const: Code: 86. DB::HTTPException: Received error from remote server http://146b4357c08d:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Ftest%2F01165%2Ftest_13%2Frmt%2Freplicas%2F1&part=20250728_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.6.10636.altinitytest (altinity build)) '. (RECEIVED_ERROR_FROM_REMOTE_IO_SERVER), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.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 const&, int&&, String const&, unsigned long&&, String const&) @ 0x000000000feda8d9 4. /build/src/IO/HTTPCommon.cpp:104: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x000000000feda6e2 5. /build/src/IO/HTTPCommon.cpp:93: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x000000000feda537 6. /build/src/IO/ReadWriteBufferFromHTTP.cpp:277: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x000000001184a4c4 7. /build/src/IO/ReadWriteBufferFromHTTP.cpp:285: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x000000001184a615 8. /build/src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x000000001184ae59 9. /build/src/IO/ReadWriteBufferFromHTTP.cpp:472: void std::__function::__policy_invoker::__call_impl[abi:se190107]>(std::__function::__policy_storage const*) @ 0x000000001184cedd 10. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001184858b 11. /build/src/IO/ReadWriteBufferFromHTTP.cpp:465: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x000000001184bf0b 12. /build/src/IO/ReadBuffer.h:60: DB::ReadBuffer::next() @ 0x000000000a148c7b 13. /build/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) @ 0x0000000011849fb2 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]>&)>&, 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&) @ 0x0000000011841980 15. /build/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) @ 0x000000001621208e 16. /build/src/Storages/StorageReplicatedMergeTree.cpp:5228: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl[abi:se190107] const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000015f9a5fe 17. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000015ed8bfd 18. /build/src/Storages/StorageReplicatedMergeTree.cpp:2514: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x0000000015ec9aab 19. /build/src/Storages/StorageReplicatedMergeTree.cpp:2349: DB::StorageReplicatedMergeTree::executeLogEntry(DB::ReplicatedMergeTreeLogEntry&) @ 0x0000000015eba91b 20. /build/src/Storages/StorageReplicatedMergeTree.cpp:3876: bool std::__function::__policy_invoker&)>::__call_impl[abi:se190107])::$_1, bool (std::shared_ptr&)>>(std::__function::__policy_storage const*, std::shared_ptr&) @ 0x0000000015f9837e 21. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000165d6fc3 22. /build/src/Storages/StorageReplicatedMergeTree.cpp:3872: DB::StorageReplicatedMergeTree::processQueueEntry(std::shared_ptr) @ 0x0000000015efc18a 23. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001624c1b2 24. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000162f9c70 25. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x00000000162fa55a 26. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc6653 27. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000000fccc4c3 28. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc3d92 29. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fcca080 30. ? @ 0x00007fbc6213eac3 31. ? @ 0x00007fbc621d0850 (version 25.3.6.10636.altinitytest (altinity build)) 2025.07.28 12:00:53.273243 [ 3977 ] {} test_13.rmt2 (7f9b740d-015c-470e-8cc6-8ba33be0dc63): auto DB::StorageReplicatedMergeTree::processQueueEntry(ReplicatedMergeTreeQueue::SelectedEntryPtr)::(anonymous class)::operator()(LogEntryPtr &) const: Code: 86. DB::HTTPException: Received error from remote server http://146b4357c08d:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Ftest%2F01165%2Ftest_13%2Frmt%2Freplicas%2F1&part=20250728_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.6.10636.altinitytest (altinity build)) '. (RECEIVED_ERROR_FROM_REMOTE_IO_SERVER), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.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 const&, int&&, String const&, unsigned long&&, String const&) @ 0x000000000feda8d9 4. /build/src/IO/HTTPCommon.cpp:104: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x000000000feda6e2 5. /build/src/IO/HTTPCommon.cpp:93: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x000000000feda537 6. /build/src/IO/ReadWriteBufferFromHTTP.cpp:277: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x000000001184a4c4 7. /build/src/IO/ReadWriteBufferFromHTTP.cpp:285: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x000000001184a615 8. /build/src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x000000001184ae59 9. /build/src/IO/ReadWriteBufferFromHTTP.cpp:472: void std::__function::__policy_invoker::__call_impl[abi:se190107]>(std::__function::__policy_storage const*) @ 0x000000001184cedd 10. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001184858b 11. /build/src/IO/ReadWriteBufferFromHTTP.cpp:465: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x000000001184bf0b 12. /build/src/IO/ReadBuffer.h:60: DB::ReadBuffer::next() @ 0x000000000a148c7b 13. /build/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) @ 0x0000000011849fb2 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]>&)>&, 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&) @ 0x0000000011841980 15. /build/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) @ 0x000000001621208e 16. /build/src/Storages/StorageReplicatedMergeTree.cpp:5228: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl[abi:se190107] const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000015f9a5fe 17. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000015ed8bfd 18. /build/src/Storages/StorageReplicatedMergeTree.cpp:2514: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x0000000015ec9aab 19. /build/src/Storages/StorageReplicatedMergeTree.cpp:2349: DB::StorageReplicatedMergeTree::executeLogEntry(DB::ReplicatedMergeTreeLogEntry&) @ 0x0000000015eba91b 20. /build/src/Storages/StorageReplicatedMergeTree.cpp:3876: bool std::__function::__policy_invoker&)>::__call_impl[abi:se190107])::$_1, bool (std::shared_ptr&)>>(std::__function::__policy_storage const*, std::shared_ptr&) @ 0x0000000015f9837e 21. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000165d6fc3 22. /build/src/Storages/StorageReplicatedMergeTree.cpp:3872: DB::StorageReplicatedMergeTree::processQueueEntry(std::shared_ptr) @ 0x0000000015efc18a 23. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001624c1b2 24. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000162f9c70 25. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x00000000162fa55a 26. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc6653 27. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000000fccc4c3 28. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc3d92 29. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fcca080 30. ? @ 0x00007fbc6213eac3 31. ? @ 0x00007fbc621d0850 (version 25.3.6.10636.altinitytest (altinity build)) 2025.07.28 12:00:53.700541 [ 3964 ] {} test_13.rmt2 (7f9b740d-015c-470e-8cc6-8ba33be0dc63): auto DB::StorageReplicatedMergeTree::processQueueEntry(ReplicatedMergeTreeQueue::SelectedEntryPtr)::(anonymous class)::operator()(LogEntryPtr &) const: Code: 86. DB::HTTPException: Received error from remote server http://146b4357c08d:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Ftest%2F01165%2Ftest_13%2Frmt%2Freplicas%2F1&part=20250728_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.6.10636.altinitytest (altinity build)) '. (RECEIVED_ERROR_FROM_REMOTE_IO_SERVER), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.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 const&, int&&, String const&, unsigned long&&, String const&) @ 0x000000000feda8d9 4. /build/src/IO/HTTPCommon.cpp:104: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x000000000feda6e2 5. /build/src/IO/HTTPCommon.cpp:93: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x000000000feda537 6. /build/src/IO/ReadWriteBufferFromHTTP.cpp:277: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x000000001184a4c4 7. /build/src/IO/ReadWriteBufferFromHTTP.cpp:285: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x000000001184a615 8. /build/src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x000000001184ae59 9. /build/src/IO/ReadWriteBufferFromHTTP.cpp:472: void std::__function::__policy_invoker::__call_impl[abi:se190107]>(std::__function::__policy_storage const*) @ 0x000000001184cedd 10. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001184858b 11. /build/src/IO/ReadWriteBufferFromHTTP.cpp:465: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x000000001184bf0b 12. /build/src/IO/ReadBuffer.h:60: DB::ReadBuffer::next() @ 0x000000000a148c7b 13. /build/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) @ 0x0000000011849fb2 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]>&)>&, 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&) @ 0x0000000011841980 15. /build/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) @ 0x000000001621208e 16. /build/src/Storages/StorageReplicatedMergeTree.cpp:5228: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl[abi:se190107] const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000015f9a5fe 17. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000015ed8bfd 18. /build/src/Storages/StorageReplicatedMergeTree.cpp:2514: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x0000000015ec9aab 19. /build/src/Storages/StorageReplicatedMergeTree.cpp:2349: DB::StorageReplicatedMergeTree::executeLogEntry(DB::ReplicatedMergeTreeLogEntry&) @ 0x0000000015eba91b 20. /build/src/Storages/StorageReplicatedMergeTree.cpp:3876: bool std::__function::__policy_invoker&)>::__call_impl[abi:se190107])::$_1, bool (std::shared_ptr&)>>(std::__function::__policy_storage const*, std::shared_ptr&) @ 0x0000000015f9837e 21. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000165d6fc3 22. /build/src/Storages/StorageReplicatedMergeTree.cpp:3872: DB::StorageReplicatedMergeTree::processQueueEntry(std::shared_ptr) @ 0x0000000015efc18a 23. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001624c1b2 24. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000162f9c70 25. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x00000000162fa55a 26. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc6653 27. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000000fccc4c3 28. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc3d92 29. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fcca080 30. ? @ 0x00007fbc6213eac3 31. ? @ 0x00007fbc621d0850 (version 25.3.6.10636.altinitytest (altinity build)) 2025.07.28 12:00:54.560204 [ 3960 ] {} test_13.rmt2 (7f9b740d-015c-470e-8cc6-8ba33be0dc63): auto DB::StorageReplicatedMergeTree::processQueueEntry(ReplicatedMergeTreeQueue::SelectedEntryPtr)::(anonymous class)::operator()(LogEntryPtr &) const: Code: 86. DB::HTTPException: Received error from remote server http://146b4357c08d:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Ftest%2F01165%2Ftest_13%2Frmt%2Freplicas%2F1&part=20250728_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.6.10636.altinitytest (altinity build)) '. (RECEIVED_ERROR_FROM_REMOTE_IO_SERVER), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.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 const&, int&&, String const&, unsigned long&&, String const&) @ 0x000000000feda8d9 4. /build/src/IO/HTTPCommon.cpp:104: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x000000000feda6e2 5. /build/src/IO/HTTPCommon.cpp:93: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x000000000feda537 6. /build/src/IO/ReadWriteBufferFromHTTP.cpp:277: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x000000001184a4c4 7. /build/src/IO/ReadWriteBufferFromHTTP.cpp:285: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x000000001184a615 8. /build/src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x000000001184ae59 9. /build/src/IO/ReadWriteBufferFromHTTP.cpp:472: void std::__function::__policy_invoker::__call_impl[abi:se190107]>(std::__function::__policy_storage const*) @ 0x000000001184cedd 10. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001184858b 11. /build/src/IO/ReadWriteBufferFromHTTP.cpp:465: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x000000001184bf0b 12. /build/src/IO/ReadBuffer.h:60: DB::ReadBuffer::next() @ 0x000000000a148c7b 13. /build/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) @ 0x0000000011849fb2 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]>&)>&, 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&) @ 0x0000000011841980 15. /build/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) @ 0x000000001621208e 16. /build/src/Storages/StorageReplicatedMergeTree.cpp:5228: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl[abi:se190107] const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000015f9a5fe 17. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000015ed8bfd 18. /build/src/Storages/StorageReplicatedMergeTree.cpp:2514: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x0000000015ec9aab 19. /build/src/Storages/StorageReplicatedMergeTree.cpp:2349: DB::StorageReplicatedMergeTree::executeLogEntry(DB::ReplicatedMergeTreeLogEntry&) @ 0x0000000015eba91b 20. /build/src/Storages/StorageReplicatedMergeTree.cpp:3876: bool std::__function::__policy_invoker&)>::__call_impl[abi:se190107])::$_1, bool (std::shared_ptr&)>>(std::__function::__policy_storage const*, std::shared_ptr&) @ 0x0000000015f9837e 21. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000165d6fc3 22. /build/src/Storages/StorageReplicatedMergeTree.cpp:3872: DB::StorageReplicatedMergeTree::processQueueEntry(std::shared_ptr) @ 0x0000000015efc18a 23. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001624c1b2 24. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000162f9c70 25. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x00000000162fa55a 26. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc6653 27. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000000fccc4c3 28. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc3d92 29. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fcca080 30. ? @ 0x00007fbc6213eac3 31. ? @ 0x00007fbc621d0850 (version 25.3.6.10636.altinitytest (altinity build)) 2025.07.28 12:00:55.042947 [ 17255 ] {244fac2f-33a5-469d-a925-a80364cca2d6} 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.6.10636.altinitytest (altinity build)) (from [::1]:55044) (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. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&) @ 0x000000000a10182b 4. /build/src/Planner/CollectTableExpressionData.cpp:272: DB::InDepthQueryTreeVisitor::visit(std::shared_ptr const&) @ 0x00000000142d02cd 5. /build/src/Analyzer/InDepthQueryTreeVisitor.h:90: DB::InDepthQueryTreeVisitor::visit(std::shared_ptr const&) @ 0x00000000142cffca 6. /build/src/Analyzer/InDepthQueryTreeVisitor.h:90: DB::InDepthQueryTreeVisitor::visit(std::shared_ptr const&) @ 0x00000000142cffca 7. /build/src/Planner/CollectTableExpressionData.cpp:364: DB::collectTableExpressionData(std::shared_ptr&, std::shared_ptr&) @ 0x00000000142cdf3f 8. /build/src/Planner/Planner.cpp:1486: DB::Planner::buildPlanForQueryNode() @ 0x0000000014978dec 9. /build/src/Planner/Planner.cpp:1308: DB::Planner::buildQueryPlanIfNeeded() @ 0x000000001497685c 10. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:255: DB::InterpreterSelectQueryAnalyzer::getQueryPlan() @ 0x000000001497476d 11. /build/src/Interpreters/executeQuery.cpp:1405: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88806 12. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 13. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 14. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 15. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 16. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 17. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 18. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 19. ? @ 0x00007fbc6213eac3 20. ? @ 0x00007fbc621d0850 2025.07.28 12:00:55.053106 [ 17255 ] {} 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. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&) @ 0x000000000a10182b 4. /build/src/Planner/CollectTableExpressionData.cpp:272: DB::InDepthQueryTreeVisitor::visit(std::shared_ptr const&) @ 0x00000000142d02cd 5. /build/src/Analyzer/InDepthQueryTreeVisitor.h:90: DB::InDepthQueryTreeVisitor::visit(std::shared_ptr const&) @ 0x00000000142cffca 6. /build/src/Analyzer/InDepthQueryTreeVisitor.h:90: DB::InDepthQueryTreeVisitor::visit(std::shared_ptr const&) @ 0x00000000142cffca 7. /build/src/Planner/CollectTableExpressionData.cpp:364: DB::collectTableExpressionData(std::shared_ptr&, std::shared_ptr&) @ 0x00000000142cdf3f 8. /build/src/Planner/Planner.cpp:1486: DB::Planner::buildPlanForQueryNode() @ 0x0000000014978dec 9. /build/src/Planner/Planner.cpp:1308: DB::Planner::buildQueryPlanIfNeeded() @ 0x000000001497685c 10. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:255: DB::InterpreterSelectQueryAnalyzer::getQueryPlan() @ 0x000000001497476d 11. /build/src/Interpreters/executeQuery.cpp:1405: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88806 12. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 13. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 14. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 15. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 16. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 17. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 18. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 19. ? @ 0x00007fbc6213eac3 20. ? @ 0x00007fbc621d0850 2025.07.28 12:00:55.287699 [ 17255 ] {5b4264db-dca2-4ef9-abb3-6aa439b4ebc2} 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.6.10636.altinitytest (altinity build)) (from [::1]:55044) (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. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&) @ 0x000000000a10182b 4. /build/src/Planner/CollectTableExpressionData.cpp:272: DB::InDepthQueryTreeVisitor::visit(std::shared_ptr const&) @ 0x00000000142d02cd 5. /build/src/Analyzer/InDepthQueryTreeVisitor.h:90: DB::InDepthQueryTreeVisitor::visit(std::shared_ptr const&) @ 0x00000000142cffca 6. /build/src/Analyzer/InDepthQueryTreeVisitor.h:90: DB::InDepthQueryTreeVisitor::visit(std::shared_ptr const&) @ 0x00000000142cffca 7. /build/src/Planner/CollectTableExpressionData.cpp:364: DB::collectTableExpressionData(std::shared_ptr&, std::shared_ptr&) @ 0x00000000142cdf3f 8. /build/src/Planner/Planner.cpp:1486: DB::Planner::buildPlanForQueryNode() @ 0x0000000014978dec 9. /build/src/Planner/Planner.cpp:1308: DB::Planner::buildQueryPlanIfNeeded() @ 0x000000001497685c 10. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:255: DB::InterpreterSelectQueryAnalyzer::getQueryPlan() @ 0x000000001497476d 11. /build/src/Interpreters/executeQuery.cpp:1405: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88806 12. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 13. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 14. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 15. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 16. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 17. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 18. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 19. ? @ 0x00007fbc6213eac3 20. ? @ 0x00007fbc621d0850 2025.07.28 12:00:55.302027 [ 17255 ] {} 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. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&) @ 0x000000000a10182b 4. /build/src/Planner/CollectTableExpressionData.cpp:272: DB::InDepthQueryTreeVisitor::visit(std::shared_ptr const&) @ 0x00000000142d02cd 5. /build/src/Analyzer/InDepthQueryTreeVisitor.h:90: DB::InDepthQueryTreeVisitor::visit(std::shared_ptr const&) @ 0x00000000142cffca 6. /build/src/Analyzer/InDepthQueryTreeVisitor.h:90: DB::InDepthQueryTreeVisitor::visit(std::shared_ptr const&) @ 0x00000000142cffca 7. /build/src/Planner/CollectTableExpressionData.cpp:364: DB::collectTableExpressionData(std::shared_ptr&, std::shared_ptr&) @ 0x00000000142cdf3f 8. /build/src/Planner/Planner.cpp:1486: DB::Planner::buildPlanForQueryNode() @ 0x0000000014978dec 9. /build/src/Planner/Planner.cpp:1308: DB::Planner::buildQueryPlanIfNeeded() @ 0x000000001497685c 10. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:255: DB::InterpreterSelectQueryAnalyzer::getQueryPlan() @ 0x000000001497476d 11. /build/src/Interpreters/executeQuery.cpp:1405: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88806 12. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 13. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 14. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 15. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 16. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 17. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 18. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 19. ? @ 0x00007fbc6213eac3 20. ? @ 0x00007fbc621d0850 2025.07.28 12:00:55.316094 [ 3969 ] {} test_13.rmt2 (7f9b740d-015c-470e-8cc6-8ba33be0dc63): auto DB::StorageReplicatedMergeTree::processQueueEntry(ReplicatedMergeTreeQueue::SelectedEntryPtr)::(anonymous class)::operator()(LogEntryPtr &) const: Code: 86. DB::HTTPException: Received error from remote server http://146b4357c08d:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Ftest%2F01165%2Ftest_13%2Frmt%2Freplicas%2F1&part=20250728_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.6.10636.altinitytest (altinity build)) '. (RECEIVED_ERROR_FROM_REMOTE_IO_SERVER), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.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 const&, int&&, String const&, unsigned long&&, String const&) @ 0x000000000feda8d9 4. /build/src/IO/HTTPCommon.cpp:104: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x000000000feda6e2 5. /build/src/IO/HTTPCommon.cpp:93: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x000000000feda537 6. /build/src/IO/ReadWriteBufferFromHTTP.cpp:277: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x000000001184a4c4 7. /build/src/IO/ReadWriteBufferFromHTTP.cpp:285: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x000000001184a615 8. /build/src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x000000001184ae59 9. /build/src/IO/ReadWriteBufferFromHTTP.cpp:472: void std::__function::__policy_invoker::__call_impl[abi:se190107]>(std::__function::__policy_storage const*) @ 0x000000001184cedd 10. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001184858b 11. /build/src/IO/ReadWriteBufferFromHTTP.cpp:465: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x000000001184bf0b 12. /build/src/IO/ReadBuffer.h:60: DB::ReadBuffer::next() @ 0x000000000a148c7b 13. /build/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) @ 0x0000000011849fb2 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]>&)>&, 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&) @ 0x0000000011841980 15. /build/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) @ 0x000000001621208e 16. /build/src/Storages/StorageReplicatedMergeTree.cpp:5228: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl[abi:se190107] const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000015f9a5fe 17. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000015ed8bfd 18. /build/src/Storages/StorageReplicatedMergeTree.cpp:2514: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x0000000015ec9aab 19. /build/src/Storages/StorageReplicatedMergeTree.cpp:2349: DB::StorageReplicatedMergeTree::executeLogEntry(DB::ReplicatedMergeTreeLogEntry&) @ 0x0000000015eba91b 20. /build/src/Storages/StorageReplicatedMergeTree.cpp:3876: bool std::__function::__policy_invoker&)>::__call_impl[abi:se190107])::$_1, bool (std::shared_ptr&)>>(std::__function::__policy_storage const*, std::shared_ptr&) @ 0x0000000015f9837e 21. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000165d6fc3 22. /build/src/Storages/StorageReplicatedMergeTree.cpp:3872: DB::StorageReplicatedMergeTree::processQueueEntry(std::shared_ptr) @ 0x0000000015efc18a 23. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001624c1b2 24. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000162f9c70 25. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x00000000162fa55a 26. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc6653 27. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000000fccc4c3 28. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc3d92 29. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fcca080 30. ? @ 0x00007fbc6213eac3 31. ? @ 0x00007fbc621d0850 (version 25.3.6.10636.altinitytest (altinity build)) 2025.07.28 12:00:56.081804 [ 3961 ] {} test_13.rmt2 (7f9b740d-015c-470e-8cc6-8ba33be0dc63): auto DB::StorageReplicatedMergeTree::processQueueEntry(ReplicatedMergeTreeQueue::SelectedEntryPtr)::(anonymous class)::operator()(LogEntryPtr &) const: Code: 86. DB::HTTPException: Received error from remote server http://146b4357c08d:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Ftest%2F01165%2Ftest_13%2Frmt%2Freplicas%2F1&part=20250728_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.6.10636.altinitytest (altinity build)) '. (RECEIVED_ERROR_FROM_REMOTE_IO_SERVER), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.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 const&, int&&, String const&, unsigned long&&, String const&) @ 0x000000000feda8d9 4. /build/src/IO/HTTPCommon.cpp:104: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x000000000feda6e2 5. /build/src/IO/HTTPCommon.cpp:93: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x000000000feda537 6. /build/src/IO/ReadWriteBufferFromHTTP.cpp:277: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x000000001184a4c4 7. /build/src/IO/ReadWriteBufferFromHTTP.cpp:285: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x000000001184a615 8. /build/src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x000000001184ae59 9. /build/src/IO/ReadWriteBufferFromHTTP.cpp:472: void std::__function::__policy_invoker::__call_impl[abi:se190107]>(std::__function::__policy_storage const*) @ 0x000000001184cedd 10. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001184858b 11. /build/src/IO/ReadWriteBufferFromHTTP.cpp:465: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x000000001184bf0b 12. /build/src/IO/ReadBuffer.h:60: DB::ReadBuffer::next() @ 0x000000000a148c7b 13. /build/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) @ 0x0000000011849fb2 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]>&)>&, 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&) @ 0x0000000011841980 15. /build/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) @ 0x000000001621208e 16. /build/src/Storages/StorageReplicatedMergeTree.cpp:5228: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl[abi:se190107] const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000015f9a5fe 17. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000015ed8bfd 18. /build/src/Storages/StorageReplicatedMergeTree.cpp:2514: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x0000000015ec9aab 19. /build/src/Storages/StorageReplicatedMergeTree.cpp:2349: DB::StorageReplicatedMergeTree::executeLogEntry(DB::ReplicatedMergeTreeLogEntry&) @ 0x0000000015eba91b 20. /build/src/Storages/StorageReplicatedMergeTree.cpp:3876: bool std::__function::__policy_invoker&)>::__call_impl[abi:se190107])::$_1, bool (std::shared_ptr&)>>(std::__function::__policy_storage const*, std::shared_ptr&) @ 0x0000000015f9837e 21. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000165d6fc3 22. /build/src/Storages/StorageReplicatedMergeTree.cpp:3872: DB::StorageReplicatedMergeTree::processQueueEntry(std::shared_ptr) @ 0x0000000015efc18a 23. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001624c1b2 24. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000162f9c70 25. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x00000000162fa55a 26. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc6653 27. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000000fccc4c3 28. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc3d92 29. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fcca080 30. ? @ 0x00007fbc6213eac3 31. ? @ 0x00007fbc621d0850 (version 25.3.6.10636.altinitytest (altinity build)) 2025.07.28 12:00:56.797622 [ 17255 ] {836bc392-69e3-4028-abd7-4c125cfca505} 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.6.10636.altinitytest (altinity build)) (from [::1]:55044) (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. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&) @ 0x000000000a10182b 4. /build/src/Planner/CollectTableExpressionData.cpp:272: DB::InDepthQueryTreeVisitor::visit(std::shared_ptr const&) @ 0x00000000142d02cd 5. /build/src/Analyzer/InDepthQueryTreeVisitor.h:90: DB::InDepthQueryTreeVisitor::visit(std::shared_ptr const&) @ 0x00000000142cffca 6. /build/src/Analyzer/InDepthQueryTreeVisitor.h:90: DB::InDepthQueryTreeVisitor::visit(std::shared_ptr const&) @ 0x00000000142cffca 7. /build/src/Planner/CollectTableExpressionData.cpp:364: DB::collectTableExpressionData(std::shared_ptr&, std::shared_ptr&) @ 0x00000000142cdf3f 8. /build/src/Planner/Planner.cpp:1486: DB::Planner::buildPlanForQueryNode() @ 0x0000000014978dec 9. /build/src/Planner/Planner.cpp:1308: DB::Planner::buildQueryPlanIfNeeded() @ 0x000000001497685c 10. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:255: DB::InterpreterSelectQueryAnalyzer::getQueryPlan() @ 0x000000001497476d 11. /build/src/Interpreters/executeQuery.cpp:1405: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88806 12. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 13. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 14. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 15. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 16. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 17. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 18. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 19. ? @ 0x00007fbc6213eac3 20. ? @ 0x00007fbc621d0850 2025.07.28 12:00:56.823165 [ 17255 ] {} 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. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&) @ 0x000000000a10182b 4. /build/src/Planner/CollectTableExpressionData.cpp:272: DB::InDepthQueryTreeVisitor::visit(std::shared_ptr const&) @ 0x00000000142d02cd 5. /build/src/Analyzer/InDepthQueryTreeVisitor.h:90: DB::InDepthQueryTreeVisitor::visit(std::shared_ptr const&) @ 0x00000000142cffca 6. /build/src/Analyzer/InDepthQueryTreeVisitor.h:90: DB::InDepthQueryTreeVisitor::visit(std::shared_ptr const&) @ 0x00000000142cffca 7. /build/src/Planner/CollectTableExpressionData.cpp:364: DB::collectTableExpressionData(std::shared_ptr&, std::shared_ptr&) @ 0x00000000142cdf3f 8. /build/src/Planner/Planner.cpp:1486: DB::Planner::buildPlanForQueryNode() @ 0x0000000014978dec 9. /build/src/Planner/Planner.cpp:1308: DB::Planner::buildQueryPlanIfNeeded() @ 0x000000001497685c 10. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:255: DB::InterpreterSelectQueryAnalyzer::getQueryPlan() @ 0x000000001497476d 11. /build/src/Interpreters/executeQuery.cpp:1405: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88806 12. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 13. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 14. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 15. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 16. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 17. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 18. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 19. ? @ 0x00007fbc6213eac3 20. ? @ 0x00007fbc621d0850 2025.07.28 12:00:57.169127 [ 3974 ] {} test_13.rmt2 (7f9b740d-015c-470e-8cc6-8ba33be0dc63): auto DB::StorageReplicatedMergeTree::processQueueEntry(ReplicatedMergeTreeQueue::SelectedEntryPtr)::(anonymous class)::operator()(LogEntryPtr &) const: Code: 86. DB::HTTPException: Received error from remote server http://146b4357c08d:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Ftest%2F01165%2Ftest_13%2Frmt%2Freplicas%2F1&part=20250728_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.6.10636.altinitytest (altinity build)) '. (RECEIVED_ERROR_FROM_REMOTE_IO_SERVER), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.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 const&, int&&, String const&, unsigned long&&, String const&) @ 0x000000000feda8d9 4. /build/src/IO/HTTPCommon.cpp:104: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x000000000feda6e2 5. /build/src/IO/HTTPCommon.cpp:93: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x000000000feda537 6. /build/src/IO/ReadWriteBufferFromHTTP.cpp:277: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x000000001184a4c4 7. /build/src/IO/ReadWriteBufferFromHTTP.cpp:285: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x000000001184a615 8. /build/src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x000000001184ae59 9. /build/src/IO/ReadWriteBufferFromHTTP.cpp:472: void std::__function::__policy_invoker::__call_impl[abi:se190107]>(std::__function::__policy_storage const*) @ 0x000000001184cedd 10. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001184858b 11. /build/src/IO/ReadWriteBufferFromHTTP.cpp:465: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x000000001184bf0b 12. /build/src/IO/ReadBuffer.h:60: DB::ReadBuffer::next() @ 0x000000000a148c7b 13. /build/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) @ 0x0000000011849fb2 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]>&)>&, 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&) @ 0x0000000011841980 15. /build/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) @ 0x000000001621208e 16. /build/src/Storages/StorageReplicatedMergeTree.cpp:5228: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl[abi:se190107] const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000015f9a5fe 17. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000015ed8bfd 18. /build/src/Storages/StorageReplicatedMergeTree.cpp:2514: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x0000000015ec9aab 19. /build/src/Storages/StorageReplicatedMergeTree.cpp:2349: DB::StorageReplicatedMergeTree::executeLogEntry(DB::ReplicatedMergeTreeLogEntry&) @ 0x0000000015eba91b 20. /build/src/Storages/StorageReplicatedMergeTree.cpp:3876: bool std::__function::__policy_invoker&)>::__call_impl[abi:se190107])::$_1, bool (std::shared_ptr&)>>(std::__function::__policy_storage const*, std::shared_ptr&) @ 0x0000000015f9837e 21. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000165d6fc3 22. /build/src/Storages/StorageReplicatedMergeTree.cpp:3872: DB::StorageReplicatedMergeTree::processQueueEntry(std::shared_ptr) @ 0x0000000015efc18a 23. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001624c1b2 24. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000162f9c70 25. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x00000000162fa55a 26. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc6653 27. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000000fccc4c3 28. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc3d92 29. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fcca080 30. ? @ 0x00007fbc6213eac3 31. ? @ 0x00007fbc621d0850 (version 25.3.6.10636.altinitytest (altinity build)) 2025.07.28 12:00:57.413165 [ 17255 ] {b65a8245-d4ec-4f73-847a-334adbd1710b} 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.6.10636.altinitytest (altinity build)) (from [::1]:55044) (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. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&) @ 0x000000000a10182b 4. /build/src/Planner/CollectTableExpressionData.cpp:272: DB::InDepthQueryTreeVisitor::visit(std::shared_ptr const&) @ 0x00000000142d02cd 5. /build/src/Analyzer/InDepthQueryTreeVisitor.h:90: DB::InDepthQueryTreeVisitor::visit(std::shared_ptr const&) @ 0x00000000142cffca 6. /build/src/Analyzer/InDepthQueryTreeVisitor.h:90: DB::InDepthQueryTreeVisitor::visit(std::shared_ptr const&) @ 0x00000000142cffca 7. /build/src/Planner/CollectTableExpressionData.cpp:364: DB::collectTableExpressionData(std::shared_ptr&, std::shared_ptr&) @ 0x00000000142cdf3f 8. /build/src/Planner/Planner.cpp:1486: DB::Planner::buildPlanForQueryNode() @ 0x0000000014978dec 9. /build/src/Planner/Planner.cpp:1308: DB::Planner::buildQueryPlanIfNeeded() @ 0x000000001497685c 10. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:255: DB::InterpreterSelectQueryAnalyzer::getQueryPlan() @ 0x000000001497476d 11. /build/src/Interpreters/executeQuery.cpp:1405: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88806 12. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 13. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 14. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 15. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 16. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 17. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 18. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 19. ? @ 0x00007fbc6213eac3 20. ? @ 0x00007fbc621d0850 2025.07.28 12:00:57.416646 [ 17255 ] {} 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. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&) @ 0x000000000a10182b 4. /build/src/Planner/CollectTableExpressionData.cpp:272: DB::InDepthQueryTreeVisitor::visit(std::shared_ptr const&) @ 0x00000000142d02cd 5. /build/src/Analyzer/InDepthQueryTreeVisitor.h:90: DB::InDepthQueryTreeVisitor::visit(std::shared_ptr const&) @ 0x00000000142cffca 6. /build/src/Analyzer/InDepthQueryTreeVisitor.h:90: DB::InDepthQueryTreeVisitor::visit(std::shared_ptr const&) @ 0x00000000142cffca 7. /build/src/Planner/CollectTableExpressionData.cpp:364: DB::collectTableExpressionData(std::shared_ptr&, std::shared_ptr&) @ 0x00000000142cdf3f 8. /build/src/Planner/Planner.cpp:1486: DB::Planner::buildPlanForQueryNode() @ 0x0000000014978dec 9. /build/src/Planner/Planner.cpp:1308: DB::Planner::buildQueryPlanIfNeeded() @ 0x000000001497685c 10. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:255: DB::InterpreterSelectQueryAnalyzer::getQueryPlan() @ 0x000000001497476d 11. /build/src/Interpreters/executeQuery.cpp:1405: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88806 12. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 13. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 14. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 15. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 16. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 17. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 18. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 19. ? @ 0x00007fbc6213eac3 20. ? @ 0x00007fbc621d0850 2025.07.28 12:00:57.892235 [ 3965 ] {} test_13.rmt2 (7f9b740d-015c-470e-8cc6-8ba33be0dc63): auto DB::StorageReplicatedMergeTree::processQueueEntry(ReplicatedMergeTreeQueue::SelectedEntryPtr)::(anonymous class)::operator()(LogEntryPtr &) const: Code: 86. DB::HTTPException: Received error from remote server http://146b4357c08d:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Ftest%2F01165%2Ftest_13%2Frmt%2Freplicas%2F1&part=20250728_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.6.10636.altinitytest (altinity build)) '. (RECEIVED_ERROR_FROM_REMOTE_IO_SERVER), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.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 const&, int&&, String const&, unsigned long&&, String const&) @ 0x000000000feda8d9 4. /build/src/IO/HTTPCommon.cpp:104: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x000000000feda6e2 5. /build/src/IO/HTTPCommon.cpp:93: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x000000000feda537 6. /build/src/IO/ReadWriteBufferFromHTTP.cpp:277: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x000000001184a4c4 7. /build/src/IO/ReadWriteBufferFromHTTP.cpp:285: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x000000001184a615 8. /build/src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x000000001184ae59 9. /build/src/IO/ReadWriteBufferFromHTTP.cpp:472: void std::__function::__policy_invoker::__call_impl[abi:se190107]>(std::__function::__policy_storage const*) @ 0x000000001184cedd 10. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001184858b 11. /build/src/IO/ReadWriteBufferFromHTTP.cpp:465: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x000000001184bf0b 12. /build/src/IO/ReadBuffer.h:60: DB::ReadBuffer::next() @ 0x000000000a148c7b 13. /build/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) @ 0x0000000011849fb2 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]>&)>&, 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&) @ 0x0000000011841980 15. /build/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) @ 0x000000001621208e 16. /build/src/Storages/StorageReplicatedMergeTree.cpp:5228: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl[abi:se190107] const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000015f9a5fe 17. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000015ed8bfd 18. /build/src/Storages/StorageReplicatedMergeTree.cpp:2514: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x0000000015ec9aab 19. /build/src/Storages/StorageReplicatedMergeTree.cpp:2349: DB::StorageReplicatedMergeTree::executeLogEntry(DB::ReplicatedMergeTreeLogEntry&) @ 0x0000000015eba91b 20. /build/src/Storages/StorageReplicatedMergeTree.cpp:3876: bool std::__function::__policy_invoker&)>::__call_impl[abi:se190107])::$_1, bool (std::shared_ptr&)>>(std::__function::__policy_storage const*, std::shared_ptr&) @ 0x0000000015f9837e 21. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000165d6fc3 22. /build/src/Storages/StorageReplicatedMergeTree.cpp:3872: DB::StorageReplicatedMergeTree::processQueueEntry(std::shared_ptr) @ 0x0000000015efc18a 23. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001624c1b2 24. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000162f9c70 25. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x00000000162fa55a 26. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc6653 27. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000000fccc4c3 28. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc3d92 29. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fcca080 30. ? @ 0x00007fbc6213eac3 31. ? @ 0x00007fbc621d0850 (version 25.3.6.10636.altinitytest (altinity build)) 2025.07.28 12:00:58.521278 [ 3970 ] {} test_13.rmt2 (7f9b740d-015c-470e-8cc6-8ba33be0dc63): auto DB::StorageReplicatedMergeTree::processQueueEntry(ReplicatedMergeTreeQueue::SelectedEntryPtr)::(anonymous class)::operator()(LogEntryPtr &) const: Code: 86. DB::HTTPException: Received error from remote server http://146b4357c08d:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Ftest%2F01165%2Ftest_13%2Frmt%2Freplicas%2F1&part=20250728_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.6.10636.altinitytest (altinity build)) '. (RECEIVED_ERROR_FROM_REMOTE_IO_SERVER), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.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 const&, int&&, String const&, unsigned long&&, String const&) @ 0x000000000feda8d9 4. /build/src/IO/HTTPCommon.cpp:104: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x000000000feda6e2 5. /build/src/IO/HTTPCommon.cpp:93: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x000000000feda537 6. /build/src/IO/ReadWriteBufferFromHTTP.cpp:277: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x000000001184a4c4 7. /build/src/IO/ReadWriteBufferFromHTTP.cpp:285: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x000000001184a615 8. /build/src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x000000001184ae59 9. /build/src/IO/ReadWriteBufferFromHTTP.cpp:472: void std::__function::__policy_invoker::__call_impl[abi:se190107]>(std::__function::__policy_storage const*) @ 0x000000001184cedd 10. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001184858b 11. /build/src/IO/ReadWriteBufferFromHTTP.cpp:465: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x000000001184bf0b 12. /build/src/IO/ReadBuffer.h:60: DB::ReadBuffer::next() @ 0x000000000a148c7b 13. /build/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) @ 0x0000000011849fb2 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]>&)>&, 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&) @ 0x0000000011841980 15. /build/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) @ 0x000000001621208e 16. /build/src/Storages/StorageReplicatedMergeTree.cpp:5228: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl[abi:se190107] const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000015f9a5fe 17. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000015ed8bfd 18. /build/src/Storages/StorageReplicatedMergeTree.cpp:2514: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x0000000015ec9aab 19. /build/src/Storages/StorageReplicatedMergeTree.cpp:2349: DB::StorageReplicatedMergeTree::executeLogEntry(DB::ReplicatedMergeTreeLogEntry&) @ 0x0000000015eba91b 20. /build/src/Storages/StorageReplicatedMergeTree.cpp:3876: bool std::__function::__policy_invoker&)>::__call_impl[abi:se190107])::$_1, bool (std::shared_ptr&)>>(std::__function::__policy_storage const*, std::shared_ptr&) @ 0x0000000015f9837e 21. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000165d6fc3 22. /build/src/Storages/StorageReplicatedMergeTree.cpp:3872: DB::StorageReplicatedMergeTree::processQueueEntry(std::shared_ptr) @ 0x0000000015efc18a 23. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001624c1b2 24. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000162f9c70 25. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x00000000162fa55a 26. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc6653 27. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000000fccc4c3 28. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc3d92 29. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fcca080 30. ? @ 0x00007fbc6213eac3 31. ? @ 0x00007fbc621d0850 (version 25.3.6.10636.altinitytest (altinity build)) 2025.07.28 12:00:58.663010 [ 17255 ] {769278c0-eac3-4336-891c-561ed0586ae1} 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.6.10636.altinitytest (altinity build)) (from [::1]:55044) (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. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&) @ 0x000000000a10182b 4. /build/src/Planner/CollectTableExpressionData.cpp:272: DB::InDepthQueryTreeVisitor::visit(std::shared_ptr const&) @ 0x00000000142d02cd 5. /build/src/Analyzer/InDepthQueryTreeVisitor.h:90: DB::InDepthQueryTreeVisitor::visit(std::shared_ptr const&) @ 0x00000000142cffca 6. /build/src/Analyzer/InDepthQueryTreeVisitor.h:90: DB::InDepthQueryTreeVisitor::visit(std::shared_ptr const&) @ 0x00000000142cffca 7. /build/src/Planner/CollectTableExpressionData.cpp:364: DB::collectTableExpressionData(std::shared_ptr&, std::shared_ptr&) @ 0x00000000142cdf3f 8. /build/src/Planner/Planner.cpp:1486: DB::Planner::buildPlanForQueryNode() @ 0x0000000014978dec 9. /build/src/Planner/Planner.cpp:1308: DB::Planner::buildQueryPlanIfNeeded() @ 0x000000001497685c 10. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:255: DB::InterpreterSelectQueryAnalyzer::getQueryPlan() @ 0x000000001497476d 11. /build/src/Interpreters/executeQuery.cpp:1405: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88806 12. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 13. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 14. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 15. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 16. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 17. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 18. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 19. ? @ 0x00007fbc6213eac3 20. ? @ 0x00007fbc621d0850 2025.07.28 12:00:58.666168 [ 17255 ] {} 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. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&) @ 0x000000000a10182b 4. /build/src/Planner/CollectTableExpressionData.cpp:272: DB::InDepthQueryTreeVisitor::visit(std::shared_ptr const&) @ 0x00000000142d02cd 5. /build/src/Analyzer/InDepthQueryTreeVisitor.h:90: DB::InDepthQueryTreeVisitor::visit(std::shared_ptr const&) @ 0x00000000142cffca 6. /build/src/Analyzer/InDepthQueryTreeVisitor.h:90: DB::InDepthQueryTreeVisitor::visit(std::shared_ptr const&) @ 0x00000000142cffca 7. /build/src/Planner/CollectTableExpressionData.cpp:364: DB::collectTableExpressionData(std::shared_ptr&, std::shared_ptr&) @ 0x00000000142cdf3f 8. /build/src/Planner/Planner.cpp:1486: DB::Planner::buildPlanForQueryNode() @ 0x0000000014978dec 9. /build/src/Planner/Planner.cpp:1308: DB::Planner::buildQueryPlanIfNeeded() @ 0x000000001497685c 10. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:255: DB::InterpreterSelectQueryAnalyzer::getQueryPlan() @ 0x000000001497476d 11. /build/src/Interpreters/executeQuery.cpp:1405: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88806 12. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 13. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 14. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 15. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 16. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 17. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 18. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 19. ? @ 0x00007fbc6213eac3 20. ? @ 0x00007fbc621d0850 2025.07.28 12:00:58.779533 [ 3961 ] {} test_13.rmt2 (7f9b740d-015c-470e-8cc6-8ba33be0dc63): auto DB::StorageReplicatedMergeTree::processQueueEntry(ReplicatedMergeTreeQueue::SelectedEntryPtr)::(anonymous class)::operator()(LogEntryPtr &) const: Code: 86. DB::HTTPException: Received error from remote server http://146b4357c08d:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Ftest%2F01165%2Ftest_13%2Frmt%2Freplicas%2F1&part=20250728_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.6.10636.altinitytest (altinity build)) '. (RECEIVED_ERROR_FROM_REMOTE_IO_SERVER), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.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 const&, int&&, String const&, unsigned long&&, String const&) @ 0x000000000feda8d9 4. /build/src/IO/HTTPCommon.cpp:104: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x000000000feda6e2 5. /build/src/IO/HTTPCommon.cpp:93: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x000000000feda537 6. /build/src/IO/ReadWriteBufferFromHTTP.cpp:277: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x000000001184a4c4 7. /build/src/IO/ReadWriteBufferFromHTTP.cpp:285: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x000000001184a615 8. /build/src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x000000001184ae59 9. /build/src/IO/ReadWriteBufferFromHTTP.cpp:472: void std::__function::__policy_invoker::__call_impl[abi:se190107]>(std::__function::__policy_storage const*) @ 0x000000001184cedd 10. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001184858b 11. /build/src/IO/ReadWriteBufferFromHTTP.cpp:465: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x000000001184bf0b 12. /build/src/IO/ReadBuffer.h:60: DB::ReadBuffer::next() @ 0x000000000a148c7b 13. /build/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) @ 0x0000000011849fb2 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]>&)>&, 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&) @ 0x0000000011841980 15. /build/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) @ 0x000000001621208e 16. /build/src/Storages/StorageReplicatedMergeTree.cpp:5228: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl[abi:se190107] const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000015f9a5fe 17. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000015ed8bfd 18. /build/src/Storages/StorageReplicatedMergeTree.cpp:2514: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x0000000015ec9aab 19. /build/src/Storages/StorageReplicatedMergeTree.cpp:2349: DB::StorageReplicatedMergeTree::executeLogEntry(DB::ReplicatedMergeTreeLogEntry&) @ 0x0000000015eba91b 20. /build/src/Storages/StorageReplicatedMergeTree.cpp:3876: bool std::__function::__policy_invoker&)>::__call_impl[abi:se190107])::$_1, bool (std::shared_ptr&)>>(std::__function::__policy_storage const*, std::shared_ptr&) @ 0x0000000015f9837e 21. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000165d6fc3 22. /build/src/Storages/StorageReplicatedMergeTree.cpp:3872: DB::StorageReplicatedMergeTree::processQueueEntry(std::shared_ptr) @ 0x0000000015efc18a 23. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001624c1b2 24. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000162f9c70 25. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x00000000162fa55a 26. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc6653 27. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000000fccc4c3 28. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc3d92 29. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fcca080 30. ? @ 0x00007fbc6213eac3 31. ? @ 0x00007fbc621d0850 (version 25.3.6.10636.altinitytest (altinity build)) 2025.07.28 12:00:59.264375 [ 17255 ] {61bb8a47-77eb-41ed-95eb-17b541972035} 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.6.10636.altinitytest (altinity build)) (from [::1]:55044) (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. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&) @ 0x000000000a10182b 4. /build/src/Planner/CollectTableExpressionData.cpp:272: DB::InDepthQueryTreeVisitor::visit(std::shared_ptr const&) @ 0x00000000142d02cd 5. /build/src/Analyzer/InDepthQueryTreeVisitor.h:90: DB::InDepthQueryTreeVisitor::visit(std::shared_ptr const&) @ 0x00000000142cffca 6. /build/src/Analyzer/InDepthQueryTreeVisitor.h:90: DB::InDepthQueryTreeVisitor::visit(std::shared_ptr const&) @ 0x00000000142cffca 7. /build/src/Planner/CollectTableExpressionData.cpp:364: DB::collectTableExpressionData(std::shared_ptr&, std::shared_ptr&) @ 0x00000000142cdf3f 8. /build/src/Planner/Planner.cpp:1486: DB::Planner::buildPlanForQueryNode() @ 0x0000000014978dec 9. /build/src/Planner/Planner.cpp:1308: DB::Planner::buildQueryPlanIfNeeded() @ 0x000000001497685c 10. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:255: DB::InterpreterSelectQueryAnalyzer::getQueryPlan() @ 0x000000001497476d 11. /build/src/Interpreters/executeQuery.cpp:1405: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88806 12. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 13. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 14. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 15. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 16. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 17. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 18. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 19. ? @ 0x00007fbc6213eac3 20. ? @ 0x00007fbc621d0850 2025.07.28 12:00:59.293553 [ 17255 ] {} 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. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&) @ 0x000000000a10182b 4. /build/src/Planner/CollectTableExpressionData.cpp:272: DB::InDepthQueryTreeVisitor::visit(std::shared_ptr const&) @ 0x00000000142d02cd 5. /build/src/Analyzer/InDepthQueryTreeVisitor.h:90: DB::InDepthQueryTreeVisitor::visit(std::shared_ptr const&) @ 0x00000000142cffca 6. /build/src/Analyzer/InDepthQueryTreeVisitor.h:90: DB::InDepthQueryTreeVisitor::visit(std::shared_ptr const&) @ 0x00000000142cffca 7. /build/src/Planner/CollectTableExpressionData.cpp:364: DB::collectTableExpressionData(std::shared_ptr&, std::shared_ptr&) @ 0x00000000142cdf3f 8. /build/src/Planner/Planner.cpp:1486: DB::Planner::buildPlanForQueryNode() @ 0x0000000014978dec 9. /build/src/Planner/Planner.cpp:1308: DB::Planner::buildQueryPlanIfNeeded() @ 0x000000001497685c 10. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:255: DB::InterpreterSelectQueryAnalyzer::getQueryPlan() @ 0x000000001497476d 11. /build/src/Interpreters/executeQuery.cpp:1405: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88806 12. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 13. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 14. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 15. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 16. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 17. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 18. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 19. ? @ 0x00007fbc6213eac3 20. ? @ 0x00007fbc621d0850 2025.07.28 12:00:59.719635 [ 3971 ] {} test_13.rmt2 (7f9b740d-015c-470e-8cc6-8ba33be0dc63): auto DB::StorageReplicatedMergeTree::processQueueEntry(ReplicatedMergeTreeQueue::SelectedEntryPtr)::(anonymous class)::operator()(LogEntryPtr &) const: Code: 86. DB::HTTPException: Received error from remote server http://146b4357c08d:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Ftest%2F01165%2Ftest_13%2Frmt%2Freplicas%2F1&part=20250728_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.6.10636.altinitytest (altinity build)) '. (RECEIVED_ERROR_FROM_REMOTE_IO_SERVER), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.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 const&, int&&, String const&, unsigned long&&, String const&) @ 0x000000000feda8d9 4. /build/src/IO/HTTPCommon.cpp:104: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x000000000feda6e2 5. /build/src/IO/HTTPCommon.cpp:93: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x000000000feda537 6. /build/src/IO/ReadWriteBufferFromHTTP.cpp:277: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x000000001184a4c4 7. /build/src/IO/ReadWriteBufferFromHTTP.cpp:285: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x000000001184a615 8. /build/src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x000000001184ae59 9. /build/src/IO/ReadWriteBufferFromHTTP.cpp:472: void std::__function::__policy_invoker::__call_impl[abi:se190107]>(std::__function::__policy_storage const*) @ 0x000000001184cedd 10. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001184858b 11. /build/src/IO/ReadWriteBufferFromHTTP.cpp:465: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x000000001184bf0b 12. /build/src/IO/ReadBuffer.h:60: DB::ReadBuffer::next() @ 0x000000000a148c7b 13. /build/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) @ 0x0000000011849fb2 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]>&)>&, 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&) @ 0x0000000011841980 15. /build/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) @ 0x000000001621208e 16. /build/src/Storages/StorageReplicatedMergeTree.cpp:5228: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl[abi:se190107] const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000015f9a5fe 17. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000015ed8bfd 18. /build/src/Storages/StorageReplicatedMergeTree.cpp:2514: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x0000000015ec9aab 19. /build/src/Storages/StorageReplicatedMergeTree.cpp:2349: DB::StorageReplicatedMergeTree::executeLogEntry(DB::ReplicatedMergeTreeLogEntry&) @ 0x0000000015eba91b 20. /build/src/Storages/StorageReplicatedMergeTree.cpp:3876: bool std::__function::__policy_invoker&)>::__call_impl[abi:se190107])::$_1, bool (std::shared_ptr&)>>(std::__function::__policy_storage const*, std::shared_ptr&) @ 0x0000000015f9837e 21. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000165d6fc3 22. /build/src/Storages/StorageReplicatedMergeTree.cpp:3872: DB::StorageReplicatedMergeTree::processQueueEntry(std::shared_ptr) @ 0x0000000015efc18a 23. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001624c1b2 24. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000162f9c70 25. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x00000000162fa55a 26. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc6653 27. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000000fccc4c3 28. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc3d92 29. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fcca080 30. ? @ 0x00007fbc6213eac3 31. ? @ 0x00007fbc621d0850 (version 25.3.6.10636.altinitytest (altinity build)) 2025.07.28 12:00:59.896855 [ 3974 ] {} test_13.rmt2 (7f9b740d-015c-470e-8cc6-8ba33be0dc63): auto DB::StorageReplicatedMergeTree::processQueueEntry(ReplicatedMergeTreeQueue::SelectedEntryPtr)::(anonymous class)::operator()(LogEntryPtr &) const: Code: 86. DB::HTTPException: Received error from remote server http://146b4357c08d:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Ftest%2F01165%2Ftest_13%2Frmt%2Freplicas%2F1&part=20250728_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.6.10636.altinitytest (altinity build)) '. (RECEIVED_ERROR_FROM_REMOTE_IO_SERVER), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.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 const&, int&&, String const&, unsigned long&&, String const&) @ 0x000000000feda8d9 4. /build/src/IO/HTTPCommon.cpp:104: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x000000000feda6e2 5. /build/src/IO/HTTPCommon.cpp:93: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x000000000feda537 6. /build/src/IO/ReadWriteBufferFromHTTP.cpp:277: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x000000001184a4c4 7. /build/src/IO/ReadWriteBufferFromHTTP.cpp:285: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x000000001184a615 8. /build/src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x000000001184ae59 9. /build/src/IO/ReadWriteBufferFromHTTP.cpp:472: void std::__function::__policy_invoker::__call_impl[abi:se190107]>(std::__function::__policy_storage const*) @ 0x000000001184cedd 10. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001184858b 11. /build/src/IO/ReadWriteBufferFromHTTP.cpp:465: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x000000001184bf0b 12. /build/src/IO/ReadBuffer.h:60: DB::ReadBuffer::next() @ 0x000000000a148c7b 13. /build/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) @ 0x0000000011849fb2 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]>&)>&, 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&) @ 0x0000000011841980 15. /build/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) @ 0x000000001621208e 16. /build/src/Storages/StorageReplicatedMergeTree.cpp:5228: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl[abi:se190107] const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000015f9a5fe 17. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000015ed8bfd 18. /build/src/Storages/StorageReplicatedMergeTree.cpp:2514: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x0000000015ec9aab 19. /build/src/Storages/StorageReplicatedMergeTree.cpp:2349: DB::StorageReplicatedMergeTree::executeLogEntry(DB::ReplicatedMergeTreeLogEntry&) @ 0x0000000015eba91b 20. /build/src/Storages/StorageReplicatedMergeTree.cpp:3876: bool std::__function::__policy_invoker&)>::__call_impl[abi:se190107])::$_1, bool (std::shared_ptr&)>>(std::__function::__policy_storage const*, std::shared_ptr&) @ 0x0000000015f9837e 21. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000165d6fc3 22. /build/src/Storages/StorageReplicatedMergeTree.cpp:3872: DB::StorageReplicatedMergeTree::processQueueEntry(std::shared_ptr) @ 0x0000000015efc18a 23. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001624c1b2 24. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000162f9c70 25. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x00000000162fa55a 26. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc6653 27. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000000fccc4c3 28. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc3d92 29. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fcca080 30. ? @ 0x00007fbc6213eac3 31. ? @ 0x00007fbc621d0850 (version 25.3.6.10636.altinitytest (altinity build)) 2025.07.28 12:01:00.073469 [ 11826 ] {} 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. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception>&, String>(int, FormatStringHelperImpl>&>::type, std::type_identity::type>, std::basic_string_view>&, String&&) @ 0x000000001385a5eb 4. /build/src/Access/SettingsConstraints.cpp:376: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000013859b18 5. /build/src/Access/SettingsConstraints.cpp:300: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000013858faf 6. /build/src/Access/SettingsConstraints.cpp:209: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000013859223 7. /build/src/Interpreters/Context.cpp:2690: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000014436134 8. /build/src/Interpreters/Context.cpp:2729: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x000000001443662b 9. /build/src/Server/HTTPHandler.cpp:457: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000001686d165 10. /build/src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x0000000016870807 11. /build/src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x0000000016907e99 12. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 13. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 14. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 15. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 16. ? @ 0x00007fbc6213eac3 17. ? @ 0x00007fbc621d0850 (version 25.3.6.10636.altinitytest (altinity build)) 2025.07.28 12:01:00.235437 [ 5951 ] {7647397c-ab16-4aff-ab53-f581eaecaf94} executeQuery: Code: 48. DB::Exception: Truncate is not supported by storage Merge. (NOT_IMPLEMENTED) (version 25.3.6.10636.altinitytest (altinity build)) (from [::1]:34640) (comment: 00458_merge_type_cast.sql) (query 23, line 33) (in query: DROP TABLE merge_32_64;), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x000000000a06b56b 4. /build/src/Storages/IStorage.cpp:171: DB::IStorage::truncate(std::shared_ptr const&, std::shared_ptr const&, std::shared_ptr, DB::TableExclusiveLockHolder&) @ 0x0000000015d1ec7a 5. /build/src/Interpreters/InterpreterDropQuery.cpp:282: DB::InterpreterDropQuery::executeToTableImpl(std::shared_ptr const&, DB::ASTDropQuery&, std::shared_ptr&, StrongTypedef, DB::UUIDTag>&) @ 0x0000000014915304 6. /build/src/Interpreters/InterpreterDropQuery.cpp:118: DB::InterpreterDropQuery::executeToTable(DB::ASTDropQuery&) @ 0x00000000149137b4 7. /build/src/Interpreters/InterpreterDropQuery.cpp:91: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000014912f07 8. /build/src/Interpreters/InterpreterDropQuery.cpp:72: DB::InterpreterDropQuery::execute() @ 0x0000000014912b65 9. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88dc9 10. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 11. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 12. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 13. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 14. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 16. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 17. ? @ 0x00007fbc6213eac3 18. ? @ 0x00007fbc621d0850 2025.07.28 12:01:00.306063 [ 5951 ] {} 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. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x000000000a06b56b 4. /build/src/Storages/IStorage.cpp:171: DB::IStorage::truncate(std::shared_ptr const&, std::shared_ptr const&, std::shared_ptr, DB::TableExclusiveLockHolder&) @ 0x0000000015d1ec7a 5. /build/src/Interpreters/InterpreterDropQuery.cpp:282: DB::InterpreterDropQuery::executeToTableImpl(std::shared_ptr const&, DB::ASTDropQuery&, std::shared_ptr&, StrongTypedef, DB::UUIDTag>&) @ 0x0000000014915304 6. /build/src/Interpreters/InterpreterDropQuery.cpp:118: DB::InterpreterDropQuery::executeToTable(DB::ASTDropQuery&) @ 0x00000000149137b4 7. /build/src/Interpreters/InterpreterDropQuery.cpp:91: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000014912f07 8. /build/src/Interpreters/InterpreterDropQuery.cpp:72: DB::InterpreterDropQuery::execute() @ 0x0000000014912b65 9. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88dc9 10. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 11. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 12. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 13. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 14. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 16. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 17. ? @ 0x00007fbc6213eac3 18. ? @ 0x00007fbc621d0850 2025.07.28 12:01:00.505147 [ 11826 ] {} 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. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x000000000c25bc4b 4. /build/src/Access/SettingsConstraints.cpp:343: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000138596e3 5. /build/src/Access/SettingsConstraints.cpp:300: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000013858faf 6. /build/src/Access/SettingsConstraints.cpp:209: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x00000000138592b8 7. /build/src/Interpreters/Context.cpp:2690: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000014436134 8. /build/src/Interpreters/Context.cpp:2729: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x000000001443662b 9. /build/src/Server/TCPHandler.cpp:2158: DB::TCPHandler::processQuery(std::optional&) @ 0x00000000168f61df 10. /build/src/Server/TCPHandler.cpp:918: DB::TCPHandler::receivePacketsExpectQuery(std::optional&) @ 0x00000000168ef965 11. /build/src/Server/TCPHandler.cpp:491: DB::TCPHandler::runImpl() @ 0x00000000168e5eb4 12. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 13. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 14. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 16. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 17. ? @ 0x00007fbc6213eac3 18. ? @ 0x00007fbc621d0850 2025.07.28 12:01:00.506506 [ 11826 ] {} 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. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000000a074fcb 4. /build/src/Server/TCPHandler.cpp:897: DB::TCPHandler::receivePacketsExpectQuery(std::optional&) @ 0x00000000168efa89 5. /build/src/Server/TCPHandler.cpp:491: DB::TCPHandler::runImpl() @ 0x00000000168e5eb4 6. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 7. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 8. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 9. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 10. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 11. ? @ 0x00007fbc6213eac3 12. ? @ 0x00007fbc621d0850 2025.07.28 12:01:00.989748 [ 3977 ] {} test_13.rmt2 (7f9b740d-015c-470e-8cc6-8ba33be0dc63): auto DB::StorageReplicatedMergeTree::processQueueEntry(ReplicatedMergeTreeQueue::SelectedEntryPtr)::(anonymous class)::operator()(LogEntryPtr &) const: Code: 86. DB::HTTPException: Received error from remote server http://146b4357c08d:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Ftest%2F01165%2Ftest_13%2Frmt%2Freplicas%2F1&part=20250728_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.6.10636.altinitytest (altinity build)) '. (RECEIVED_ERROR_FROM_REMOTE_IO_SERVER), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.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 const&, int&&, String const&, unsigned long&&, String const&) @ 0x000000000feda8d9 4. /build/src/IO/HTTPCommon.cpp:104: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x000000000feda6e2 5. /build/src/IO/HTTPCommon.cpp:93: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x000000000feda537 6. /build/src/IO/ReadWriteBufferFromHTTP.cpp:277: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x000000001184a4c4 7. /build/src/IO/ReadWriteBufferFromHTTP.cpp:285: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x000000001184a615 8. /build/src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x000000001184ae59 9. /build/src/IO/ReadWriteBufferFromHTTP.cpp:472: void std::__function::__policy_invoker::__call_impl[abi:se190107]>(std::__function::__policy_storage const*) @ 0x000000001184cedd 10. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001184858b 11. /build/src/IO/ReadWriteBufferFromHTTP.cpp:465: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x000000001184bf0b 12. /build/src/IO/ReadBuffer.h:60: DB::ReadBuffer::next() @ 0x000000000a148c7b 13. /build/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) @ 0x0000000011849fb2 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]>&)>&, 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&) @ 0x0000000011841980 15. /build/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) @ 0x000000001621208e 16. /build/src/Storages/StorageReplicatedMergeTree.cpp:5228: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl[abi:se190107] const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000015f9a5fe 17. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000015ed8bfd 18. /build/src/Storages/StorageReplicatedMergeTree.cpp:2514: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x0000000015ec9aab 19. /build/src/Storages/StorageReplicatedMergeTree.cpp:2349: DB::StorageReplicatedMergeTree::executeLogEntry(DB::ReplicatedMergeTreeLogEntry&) @ 0x0000000015eba91b 20. /build/src/Storages/StorageReplicatedMergeTree.cpp:3876: bool std::__function::__policy_invoker&)>::__call_impl[abi:se190107])::$_1, bool (std::shared_ptr&)>>(std::__function::__policy_storage const*, std::shared_ptr&) @ 0x0000000015f9837e 21. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000165d6fc3 22. /build/src/Storages/StorageReplicatedMergeTree.cpp:3872: DB::StorageReplicatedMergeTree::processQueueEntry(std::shared_ptr) @ 0x0000000015efc18a 23. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001624c1b2 24. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000162f9c70 25. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x00000000162fa55a 26. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc6653 27. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000000fccc4c3 28. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc3d92 29. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fcca080 30. ? @ 0x00007fbc6213eac3 31. ? @ 0x00007fbc621d0850 (version 25.3.6.10636.altinitytest (altinity build)) 2025.07.28 12:01:01.252616 [ 3976 ] {} test_13.rmt2 (7f9b740d-015c-470e-8cc6-8ba33be0dc63): auto DB::StorageReplicatedMergeTree::processQueueEntry(ReplicatedMergeTreeQueue::SelectedEntryPtr)::(anonymous class)::operator()(LogEntryPtr &) const: Code: 86. DB::HTTPException: Received error from remote server http://146b4357c08d:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Ftest%2F01165%2Ftest_13%2Frmt%2Freplicas%2F1&part=20250728_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.6.10636.altinitytest (altinity build)) '. (RECEIVED_ERROR_FROM_REMOTE_IO_SERVER), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.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 const&, int&&, String const&, unsigned long&&, String const&) @ 0x000000000feda8d9 4. /build/src/IO/HTTPCommon.cpp:104: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x000000000feda6e2 5. /build/src/IO/HTTPCommon.cpp:93: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x000000000feda537 6. /build/src/IO/ReadWriteBufferFromHTTP.cpp:277: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x000000001184a4c4 7. /build/src/IO/ReadWriteBufferFromHTTP.cpp:285: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x000000001184a615 8. /build/src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x000000001184ae59 9. /build/src/IO/ReadWriteBufferFromHTTP.cpp:472: void std::__function::__policy_invoker::__call_impl[abi:se190107]>(std::__function::__policy_storage const*) @ 0x000000001184cedd 10. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001184858b 11. /build/src/IO/ReadWriteBufferFromHTTP.cpp:465: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x000000001184bf0b 12. /build/src/IO/ReadBuffer.h:60: DB::ReadBuffer::next() @ 0x000000000a148c7b 13. /build/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) @ 0x0000000011849fb2 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]>&)>&, 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&) @ 0x0000000011841980 15. /build/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) @ 0x000000001621208e 16. /build/src/Storages/StorageReplicatedMergeTree.cpp:5228: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl[abi:se190107] const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000015f9a5fe 17. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000015ed8bfd 18. /build/src/Storages/StorageReplicatedMergeTree.cpp:2514: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x0000000015ec9aab 19. /build/src/Storages/StorageReplicatedMergeTree.cpp:2349: DB::StorageReplicatedMergeTree::executeLogEntry(DB::ReplicatedMergeTreeLogEntry&) @ 0x0000000015eba91b 20. /build/src/Storages/StorageReplicatedMergeTree.cpp:3876: bool std::__function::__policy_invoker&)>::__call_impl[abi:se190107])::$_1, bool (std::shared_ptr&)>>(std::__function::__policy_storage const*, std::shared_ptr&) @ 0x0000000015f9837e 21. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000165d6fc3 22. /build/src/Storages/StorageReplicatedMergeTree.cpp:3872: DB::StorageReplicatedMergeTree::processQueueEntry(std::shared_ptr) @ 0x0000000015efc18a 23. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001624c1b2 24. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000162f9c70 25. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x00000000162fa55a 26. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc6653 27. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000000fccc4c3 28. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc3d92 29. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fcca080 30. ? @ 0x00007fbc6213eac3 31. ? @ 0x00007fbc621d0850 (version 25.3.6.10636.altinitytest (altinity build)) 2025.07.28 12:01:01.290336 [ 17255 ] {5b6f4215-4dc5-4dfe-9b3d-afb9376254cb} 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.6.10636.altinitytest (altinity build)) (from [::1]:55044) (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. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&) @ 0x000000000a10182b 4. /build/src/Planner/CollectTableExpressionData.cpp:272: DB::InDepthQueryTreeVisitor::visit(std::shared_ptr const&) @ 0x00000000142d02cd 5. /build/src/Analyzer/InDepthQueryTreeVisitor.h:90: DB::InDepthQueryTreeVisitor::visit(std::shared_ptr const&) @ 0x00000000142cffca 6. /build/src/Analyzer/InDepthQueryTreeVisitor.h:90: DB::InDepthQueryTreeVisitor::visit(std::shared_ptr const&) @ 0x00000000142cffca 7. /build/src/Planner/CollectTableExpressionData.cpp:364: DB::collectTableExpressionData(std::shared_ptr&, std::shared_ptr&) @ 0x00000000142cdf3f 8. /build/src/Planner/Planner.cpp:1486: DB::Planner::buildPlanForQueryNode() @ 0x0000000014978dec 9. /build/src/Planner/Planner.cpp:1308: DB::Planner::buildQueryPlanIfNeeded() @ 0x000000001497685c 10. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:255: DB::InterpreterSelectQueryAnalyzer::getQueryPlan() @ 0x000000001497476d 11. /build/src/Interpreters/executeQuery.cpp:1405: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88806 12. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 13. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 14. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 15. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 16. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 17. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 18. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 19. ? @ 0x00007fbc6213eac3 20. ? @ 0x00007fbc621d0850 2025.07.28 12:01:01.295164 [ 17255 ] {} 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. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&) @ 0x000000000a10182b 4. /build/src/Planner/CollectTableExpressionData.cpp:272: DB::InDepthQueryTreeVisitor::visit(std::shared_ptr const&) @ 0x00000000142d02cd 5. /build/src/Analyzer/InDepthQueryTreeVisitor.h:90: DB::InDepthQueryTreeVisitor::visit(std::shared_ptr const&) @ 0x00000000142cffca 6. /build/src/Analyzer/InDepthQueryTreeVisitor.h:90: DB::InDepthQueryTreeVisitor::visit(std::shared_ptr const&) @ 0x00000000142cffca 7. /build/src/Planner/CollectTableExpressionData.cpp:364: DB::collectTableExpressionData(std::shared_ptr&, std::shared_ptr&) @ 0x00000000142cdf3f 8. /build/src/Planner/Planner.cpp:1486: DB::Planner::buildPlanForQueryNode() @ 0x0000000014978dec 9. /build/src/Planner/Planner.cpp:1308: DB::Planner::buildQueryPlanIfNeeded() @ 0x000000001497685c 10. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:255: DB::InterpreterSelectQueryAnalyzer::getQueryPlan() @ 0x000000001497476d 11. /build/src/Interpreters/executeQuery.cpp:1405: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88806 12. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 13. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 14. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 15. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 16. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 17. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 18. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 19. ? @ 0x00007fbc6213eac3 20. ? @ 0x00007fbc621d0850 2025.07.28 12:01:01.422559 [ 3964 ] {} test_13.rmt2 (7f9b740d-015c-470e-8cc6-8ba33be0dc63): auto DB::StorageReplicatedMergeTree::processQueueEntry(ReplicatedMergeTreeQueue::SelectedEntryPtr)::(anonymous class)::operator()(LogEntryPtr &) const: Code: 86. DB::HTTPException: Received error from remote server http://146b4357c08d:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Ftest%2F01165%2Ftest_13%2Frmt%2Freplicas%2F1&part=20250728_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.6.10636.altinitytest (altinity build)) '. (RECEIVED_ERROR_FROM_REMOTE_IO_SERVER), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.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 const&, int&&, String const&, unsigned long&&, String const&) @ 0x000000000feda8d9 4. /build/src/IO/HTTPCommon.cpp:104: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x000000000feda6e2 5. /build/src/IO/HTTPCommon.cpp:93: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x000000000feda537 6. /build/src/IO/ReadWriteBufferFromHTTP.cpp:277: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x000000001184a4c4 7. /build/src/IO/ReadWriteBufferFromHTTP.cpp:285: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x000000001184a615 8. /build/src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x000000001184ae59 9. /build/src/IO/ReadWriteBufferFromHTTP.cpp:472: void std::__function::__policy_invoker::__call_impl[abi:se190107]>(std::__function::__policy_storage const*) @ 0x000000001184cedd 10. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001184858b 11. /build/src/IO/ReadWriteBufferFromHTTP.cpp:465: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x000000001184bf0b 12. /build/src/IO/ReadBuffer.h:60: DB::ReadBuffer::next() @ 0x000000000a148c7b 13. /build/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) @ 0x0000000011849fb2 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]>&)>&, 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&) @ 0x0000000011841980 15. /build/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) @ 0x000000001621208e 16. /build/src/Storages/StorageReplicatedMergeTree.cpp:5228: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl[abi:se190107] const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000015f9a5fe 17. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000015ed8bfd 18. /build/src/Storages/StorageReplicatedMergeTree.cpp:2514: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x0000000015ec9aab 19. /build/src/Storages/StorageReplicatedMergeTree.cpp:2349: DB::StorageReplicatedMergeTree::executeLogEntry(DB::ReplicatedMergeTreeLogEntry&) @ 0x0000000015eba91b 20. /build/src/Storages/StorageReplicatedMergeTree.cpp:3876: bool std::__function::__policy_invoker&)>::__call_impl[abi:se190107])::$_1, bool (std::shared_ptr&)>>(std::__function::__policy_storage const*, std::shared_ptr&) @ 0x0000000015f9837e 21. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000165d6fc3 22. /build/src/Storages/StorageReplicatedMergeTree.cpp:3872: DB::StorageReplicatedMergeTree::processQueueEntry(std::shared_ptr) @ 0x0000000015efc18a 23. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001624c1b2 24. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000162f9c70 25. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x00000000162fa55a 26. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc6653 27. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000000fccc4c3 28. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc3d92 29. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fcca080 30. ? @ 0x00007fbc6213eac3 31. ? @ 0x00007fbc621d0850 (version 25.3.6.10636.altinitytest (altinity build)) 2025.07.28 12:01:01.807215 [ 3967 ] {} test_13.rmt2 (7f9b740d-015c-470e-8cc6-8ba33be0dc63): auto DB::StorageReplicatedMergeTree::processQueueEntry(ReplicatedMergeTreeQueue::SelectedEntryPtr)::(anonymous class)::operator()(LogEntryPtr &) const: Code: 86. DB::HTTPException: Received error from remote server http://146b4357c08d:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Ftest%2F01165%2Ftest_13%2Frmt%2Freplicas%2F1&part=20250728_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.6.10636.altinitytest (altinity build)) '. (RECEIVED_ERROR_FROM_REMOTE_IO_SERVER), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.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 const&, int&&, String const&, unsigned long&&, String const&) @ 0x000000000feda8d9 4. /build/src/IO/HTTPCommon.cpp:104: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x000000000feda6e2 5. /build/src/IO/HTTPCommon.cpp:93: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x000000000feda537 6. /build/src/IO/ReadWriteBufferFromHTTP.cpp:277: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x000000001184a4c4 7. /build/src/IO/ReadWriteBufferFromHTTP.cpp:285: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x000000001184a615 8. /build/src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x000000001184ae59 9. /build/src/IO/ReadWriteBufferFromHTTP.cpp:472: void std::__function::__policy_invoker::__call_impl[abi:se190107]>(std::__function::__policy_storage const*) @ 0x000000001184cedd 10. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001184858b 11. /build/src/IO/ReadWriteBufferFromHTTP.cpp:465: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x000000001184bf0b 12. /build/src/IO/ReadBuffer.h:60: DB::ReadBuffer::next() @ 0x000000000a148c7b 13. /build/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) @ 0x0000000011849fb2 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]>&)>&, 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&) @ 0x0000000011841980 15. /build/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) @ 0x000000001621208e 16. /build/src/Storages/StorageReplicatedMergeTree.cpp:5228: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl[abi:se190107] const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000015f9a5fe 17. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000015ed8bfd 18. /build/src/Storages/StorageReplicatedMergeTree.cpp:2514: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x0000000015ec9aab 19. /build/src/Storages/StorageReplicatedMergeTree.cpp:2349: DB::StorageReplicatedMergeTree::executeLogEntry(DB::ReplicatedMergeTreeLogEntry&) @ 0x0000000015eba91b 20. /build/src/Storages/StorageReplicatedMergeTree.cpp:3876: bool std::__function::__policy_invoker&)>::__call_impl[abi:se190107])::$_1, bool (std::shared_ptr&)>>(std::__function::__policy_storage const*, std::shared_ptr&) @ 0x0000000015f9837e 21. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000165d6fc3 22. /build/src/Storages/StorageReplicatedMergeTree.cpp:3872: DB::StorageReplicatedMergeTree::processQueueEntry(std::shared_ptr) @ 0x0000000015efc18a 23. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001624c1b2 24. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000162f9c70 25. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x00000000162fa55a 26. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc6653 27. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000000fccc4c3 28. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc3d92 29. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fcca080 30. ? @ 0x00007fbc6213eac3 31. ? @ 0x00007fbc621d0850 (version 25.3.6.10636.altinitytest (altinity build)) 2025.07.28 12:01:01.824892 [ 17255 ] {5b6714b5-b571-4781-a715-52e97b2930de} 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.6.10636.altinitytest (altinity build)) (from [::1]:55044) (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. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&) @ 0x000000000a10182b 4. /build/src/Planner/CollectTableExpressionData.cpp:272: DB::InDepthQueryTreeVisitor::visit(std::shared_ptr const&) @ 0x00000000142d02cd 5. /build/src/Analyzer/InDepthQueryTreeVisitor.h:90: DB::InDepthQueryTreeVisitor::visit(std::shared_ptr const&) @ 0x00000000142cffca 6. /build/src/Analyzer/InDepthQueryTreeVisitor.h:90: DB::InDepthQueryTreeVisitor::visit(std::shared_ptr const&) @ 0x00000000142cffca 7. /build/src/Planner/CollectTableExpressionData.cpp:364: DB::collectTableExpressionData(std::shared_ptr&, std::shared_ptr&) @ 0x00000000142cdf3f 8. /build/src/Planner/Planner.cpp:1486: DB::Planner::buildPlanForQueryNode() @ 0x0000000014978dec 9. /build/src/Planner/Planner.cpp:1308: DB::Planner::buildQueryPlanIfNeeded() @ 0x000000001497685c 10. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:255: DB::InterpreterSelectQueryAnalyzer::getQueryPlan() @ 0x000000001497476d 11. /build/src/Interpreters/executeQuery.cpp:1405: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88806 12. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 13. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 14. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 15. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 16. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 17. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 18. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 19. ? @ 0x00007fbc6213eac3 20. ? @ 0x00007fbc621d0850 2025.07.28 12:01:01.828125 [ 17255 ] {} 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. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&) @ 0x000000000a10182b 4. /build/src/Planner/CollectTableExpressionData.cpp:272: DB::InDepthQueryTreeVisitor::visit(std::shared_ptr const&) @ 0x00000000142d02cd 5. /build/src/Analyzer/InDepthQueryTreeVisitor.h:90: DB::InDepthQueryTreeVisitor::visit(std::shared_ptr const&) @ 0x00000000142cffca 6. /build/src/Analyzer/InDepthQueryTreeVisitor.h:90: DB::InDepthQueryTreeVisitor::visit(std::shared_ptr const&) @ 0x00000000142cffca 7. /build/src/Planner/CollectTableExpressionData.cpp:364: DB::collectTableExpressionData(std::shared_ptr&, std::shared_ptr&) @ 0x00000000142cdf3f 8. /build/src/Planner/Planner.cpp:1486: DB::Planner::buildPlanForQueryNode() @ 0x0000000014978dec 9. /build/src/Planner/Planner.cpp:1308: DB::Planner::buildQueryPlanIfNeeded() @ 0x000000001497685c 10. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:255: DB::InterpreterSelectQueryAnalyzer::getQueryPlan() @ 0x000000001497476d 11. /build/src/Interpreters/executeQuery.cpp:1405: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88806 12. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 13. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 14. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 15. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 16. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 17. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 18. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 19. ? @ 0x00007fbc6213eac3 20. ? @ 0x00007fbc621d0850 2025.07.28 12:01:02.280169 [ 3977 ] {} test_13.rmt2 (7f9b740d-015c-470e-8cc6-8ba33be0dc63): auto DB::StorageReplicatedMergeTree::processQueueEntry(ReplicatedMergeTreeQueue::SelectedEntryPtr)::(anonymous class)::operator()(LogEntryPtr &) const: Code: 86. DB::HTTPException: Received error from remote server http://146b4357c08d:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Ftest%2F01165%2Ftest_13%2Frmt%2Freplicas%2F1&part=20250728_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.6.10636.altinitytest (altinity build)) '. (RECEIVED_ERROR_FROM_REMOTE_IO_SERVER), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.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 const&, int&&, String const&, unsigned long&&, String const&) @ 0x000000000feda8d9 4. /build/src/IO/HTTPCommon.cpp:104: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x000000000feda6e2 5. /build/src/IO/HTTPCommon.cpp:93: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x000000000feda537 6. /build/src/IO/ReadWriteBufferFromHTTP.cpp:277: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x000000001184a4c4 7. /build/src/IO/ReadWriteBufferFromHTTP.cpp:285: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x000000001184a615 8. /build/src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x000000001184ae59 9. /build/src/IO/ReadWriteBufferFromHTTP.cpp:472: void std::__function::__policy_invoker::__call_impl[abi:se190107]>(std::__function::__policy_storage const*) @ 0x000000001184cedd 10. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001184858b 11. /build/src/IO/ReadWriteBufferFromHTTP.cpp:465: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x000000001184bf0b 12. /build/src/IO/ReadBuffer.h:60: DB::ReadBuffer::next() @ 0x000000000a148c7b 13. /build/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) @ 0x0000000011849fb2 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]>&)>&, 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&) @ 0x0000000011841980 15. /build/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) @ 0x000000001621208e 16. /build/src/Storages/StorageReplicatedMergeTree.cpp:5228: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl[abi:se190107] const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000015f9a5fe 17. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000015ed8bfd 18. /build/src/Storages/StorageReplicatedMergeTree.cpp:2514: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x0000000015ec9aab 19. /build/src/Storages/StorageReplicatedMergeTree.cpp:2349: DB::StorageReplicatedMergeTree::executeLogEntry(DB::ReplicatedMergeTreeLogEntry&) @ 0x0000000015eba91b 20. /build/src/Storages/StorageReplicatedMergeTree.cpp:3876: bool std::__function::__policy_invoker&)>::__call_impl[abi:se190107])::$_1, bool (std::shared_ptr&)>>(std::__function::__policy_storage const*, std::shared_ptr&) @ 0x0000000015f9837e 21. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000165d6fc3 22. /build/src/Storages/StorageReplicatedMergeTree.cpp:3872: DB::StorageReplicatedMergeTree::processQueueEntry(std::shared_ptr) @ 0x0000000015efc18a 23. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001624c1b2 24. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000162f9c70 25. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x00000000162fa55a 26. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc6653 27. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000000fccc4c3 28. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc3d92 29. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fcca080 30. ? @ 0x00007fbc6213eac3 31. ? @ 0x00007fbc621d0850 (version 25.3.6.10636.altinitytest (altinity build)) 2025.07.28 12:01:02.451339 [ 3970 ] {} test_13.rmt2 (7f9b740d-015c-470e-8cc6-8ba33be0dc63): auto DB::StorageReplicatedMergeTree::processQueueEntry(ReplicatedMergeTreeQueue::SelectedEntryPtr)::(anonymous class)::operator()(LogEntryPtr &) const: Code: 86. DB::HTTPException: Received error from remote server http://146b4357c08d:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Ftest%2F01165%2Ftest_13%2Frmt%2Freplicas%2F1&part=20250728_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.6.10636.altinitytest (altinity build)) '. (RECEIVED_ERROR_FROM_REMOTE_IO_SERVER), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.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 const&, int&&, String const&, unsigned long&&, String const&) @ 0x000000000feda8d9 4. /build/src/IO/HTTPCommon.cpp:104: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x000000000feda6e2 5. /build/src/IO/HTTPCommon.cpp:93: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x000000000feda537 6. /build/src/IO/ReadWriteBufferFromHTTP.cpp:277: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x000000001184a4c4 7. /build/src/IO/ReadWriteBufferFromHTTP.cpp:285: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x000000001184a615 8. /build/src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x000000001184ae59 9. /build/src/IO/ReadWriteBufferFromHTTP.cpp:472: void std::__function::__policy_invoker::__call_impl[abi:se190107]>(std::__function::__policy_storage const*) @ 0x000000001184cedd 10. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001184858b 11. /build/src/IO/ReadWriteBufferFromHTTP.cpp:465: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x000000001184bf0b 12. /build/src/IO/ReadBuffer.h:60: DB::ReadBuffer::next() @ 0x000000000a148c7b 13. /build/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) @ 0x0000000011849fb2 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]>&)>&, 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&) @ 0x0000000011841980 15. /build/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) @ 0x000000001621208e 16. /build/src/Storages/StorageReplicatedMergeTree.cpp:5228: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl[abi:se190107] const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000015f9a5fe 17. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000015ed8bfd 18. /build/src/Storages/StorageReplicatedMergeTree.cpp:2514: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x0000000015ec9aab 19. /build/src/Storages/StorageReplicatedMergeTree.cpp:2349: DB::StorageReplicatedMergeTree::executeLogEntry(DB::ReplicatedMergeTreeLogEntry&) @ 0x0000000015eba91b 20. /build/src/Storages/StorageReplicatedMergeTree.cpp:3876: bool std::__function::__policy_invoker&)>::__call_impl[abi:se190107])::$_1, bool (std::shared_ptr&)>>(std::__function::__policy_storage const*, std::shared_ptr&) @ 0x0000000015f9837e 21. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000165d6fc3 22. /build/src/Storages/StorageReplicatedMergeTree.cpp:3872: DB::StorageReplicatedMergeTree::processQueueEntry(std::shared_ptr) @ 0x0000000015efc18a 23. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001624c1b2 24. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000162f9c70 25. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x00000000162fa55a 26. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc6653 27. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000000fccc4c3 28. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc3d92 29. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fcca080 30. ? @ 0x00007fbc6213eac3 31. ? @ 0x00007fbc621d0850 (version 25.3.6.10636.altinitytest (altinity build)) 2025.07.28 12:01:02.949299 [ 3968 ] {} test_13.rmt2 (7f9b740d-015c-470e-8cc6-8ba33be0dc63): auto DB::StorageReplicatedMergeTree::processQueueEntry(ReplicatedMergeTreeQueue::SelectedEntryPtr)::(anonymous class)::operator()(LogEntryPtr &) const: Code: 86. DB::HTTPException: Received error from remote server http://146b4357c08d:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Ftest%2F01165%2Ftest_13%2Frmt%2Freplicas%2F1&part=20250728_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.6.10636.altinitytest (altinity build)) '. (RECEIVED_ERROR_FROM_REMOTE_IO_SERVER), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.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 const&, int&&, String const&, unsigned long&&, String const&) @ 0x000000000feda8d9 4. /build/src/IO/HTTPCommon.cpp:104: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x000000000feda6e2 5. /build/src/IO/HTTPCommon.cpp:93: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x000000000feda537 6. /build/src/IO/ReadWriteBufferFromHTTP.cpp:277: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x000000001184a4c4 7. /build/src/IO/ReadWriteBufferFromHTTP.cpp:285: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x000000001184a615 8. /build/src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x000000001184ae59 9. /build/src/IO/ReadWriteBufferFromHTTP.cpp:472: void std::__function::__policy_invoker::__call_impl[abi:se190107]>(std::__function::__policy_storage const*) @ 0x000000001184cedd 10. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001184858b 11. /build/src/IO/ReadWriteBufferFromHTTP.cpp:465: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x000000001184bf0b 12. /build/src/IO/ReadBuffer.h:60: DB::ReadBuffer::next() @ 0x000000000a148c7b 13. /build/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) @ 0x0000000011849fb2 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]>&)>&, 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&) @ 0x0000000011841980 15. /build/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) @ 0x000000001621208e 16. /build/src/Storages/StorageReplicatedMergeTree.cpp:5228: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl[abi:se190107] const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000015f9a5fe 17. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000015ed8bfd 18. /build/src/Storages/StorageReplicatedMergeTree.cpp:2514: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x0000000015ec9aab 19. /build/src/Storages/StorageReplicatedMergeTree.cpp:2349: DB::StorageReplicatedMergeTree::executeLogEntry(DB::ReplicatedMergeTreeLogEntry&) @ 0x0000000015eba91b 20. /build/src/Storages/StorageReplicatedMergeTree.cpp:3876: bool std::__function::__policy_invoker&)>::__call_impl[abi:se190107])::$_1, bool (std::shared_ptr&)>>(std::__function::__policy_storage const*, std::shared_ptr&) @ 0x0000000015f9837e 21. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000165d6fc3 22. /build/src/Storages/StorageReplicatedMergeTree.cpp:3872: DB::StorageReplicatedMergeTree::processQueueEntry(std::shared_ptr) @ 0x0000000015efc18a 23. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001624c1b2 24. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000162f9c70 25. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x00000000162fa55a 26. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc6653 27. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000000fccc4c3 28. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc3d92 29. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fcca080 30. ? @ 0x00007fbc6213eac3 31. ? @ 0x00007fbc621d0850 (version 25.3.6.10636.altinitytest (altinity build)) 2025.07.28 12:01:03.682167 [ 3971 ] {} test_13.rmt2 (7f9b740d-015c-470e-8cc6-8ba33be0dc63): auto DB::StorageReplicatedMergeTree::processQueueEntry(ReplicatedMergeTreeQueue::SelectedEntryPtr)::(anonymous class)::operator()(LogEntryPtr &) const: Code: 86. DB::HTTPException: Received error from remote server http://146b4357c08d:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Ftest%2F01165%2Ftest_13%2Frmt%2Freplicas%2F1&part=20250728_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.6.10636.altinitytest (altinity build)) '. (RECEIVED_ERROR_FROM_REMOTE_IO_SERVER), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.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 const&, int&&, String const&, unsigned long&&, String const&) @ 0x000000000feda8d9 4. /build/src/IO/HTTPCommon.cpp:104: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x000000000feda6e2 5. /build/src/IO/HTTPCommon.cpp:93: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x000000000feda537 6. /build/src/IO/ReadWriteBufferFromHTTP.cpp:277: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x000000001184a4c4 7. /build/src/IO/ReadWriteBufferFromHTTP.cpp:285: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x000000001184a615 8. /build/src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x000000001184ae59 9. /build/src/IO/ReadWriteBufferFromHTTP.cpp:472: void std::__function::__policy_invoker::__call_impl[abi:se190107]>(std::__function::__policy_storage const*) @ 0x000000001184cedd 10. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001184858b 11. /build/src/IO/ReadWriteBufferFromHTTP.cpp:465: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x000000001184bf0b 12. /build/src/IO/ReadBuffer.h:60: DB::ReadBuffer::next() @ 0x000000000a148c7b 13. /build/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) @ 0x0000000011849fb2 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]>&)>&, 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&) @ 0x0000000011841980 15. /build/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) @ 0x000000001621208e 16. /build/src/Storages/StorageReplicatedMergeTree.cpp:5228: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl[abi:se190107] const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000015f9a5fe 17. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000015ed8bfd 18. /build/src/Storages/StorageReplicatedMergeTree.cpp:2514: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x0000000015ec9aab 19. /build/src/Storages/StorageReplicatedMergeTree.cpp:2349: DB::StorageReplicatedMergeTree::executeLogEntry(DB::ReplicatedMergeTreeLogEntry&) @ 0x0000000015eba91b 20. /build/src/Storages/StorageReplicatedMergeTree.cpp:3876: bool std::__function::__policy_invoker&)>::__call_impl[abi:se190107])::$_1, bool (std::shared_ptr&)>>(std::__function::__policy_storage const*, std::shared_ptr&) @ 0x0000000015f9837e 21. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000165d6fc3 22. /build/src/Storages/StorageReplicatedMergeTree.cpp:3872: DB::StorageReplicatedMergeTree::processQueueEntry(std::shared_ptr) @ 0x0000000015efc18a 23. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001624c1b2 24. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000162f9c70 25. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x00000000162fa55a 26. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc6653 27. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000000fccc4c3 28. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc3d92 29. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fcca080 30. ? @ 0x00007fbc6213eac3 31. ? @ 0x00007fbc621d0850 (version 25.3.6.10636.altinitytest (altinity build)) 2025.07.28 12:01:04.001812 [ 3962 ] {} test_13.rmt2 (7f9b740d-015c-470e-8cc6-8ba33be0dc63): auto DB::StorageReplicatedMergeTree::processQueueEntry(ReplicatedMergeTreeQueue::SelectedEntryPtr)::(anonymous class)::operator()(LogEntryPtr &) const: Code: 86. DB::HTTPException: Received error from remote server http://146b4357c08d:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Ftest%2F01165%2Ftest_13%2Frmt%2Freplicas%2F1&part=20250728_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.6.10636.altinitytest (altinity build)) '. (RECEIVED_ERROR_FROM_REMOTE_IO_SERVER), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.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 const&, int&&, String const&, unsigned long&&, String const&) @ 0x000000000feda8d9 4. /build/src/IO/HTTPCommon.cpp:104: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x000000000feda6e2 5. /build/src/IO/HTTPCommon.cpp:93: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x000000000feda537 6. /build/src/IO/ReadWriteBufferFromHTTP.cpp:277: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x000000001184a4c4 7. /build/src/IO/ReadWriteBufferFromHTTP.cpp:285: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x000000001184a615 8. /build/src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x000000001184ae59 9. /build/src/IO/ReadWriteBufferFromHTTP.cpp:472: void std::__function::__policy_invoker::__call_impl[abi:se190107]>(std::__function::__policy_storage const*) @ 0x000000001184cedd 10. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001184858b 11. /build/src/IO/ReadWriteBufferFromHTTP.cpp:465: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x000000001184bf0b 12. /build/src/IO/ReadBuffer.h:60: DB::ReadBuffer::next() @ 0x000000000a148c7b 13. /build/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) @ 0x0000000011849fb2 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]>&)>&, 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&) @ 0x0000000011841980 15. /build/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) @ 0x000000001621208e 16. /build/src/Storages/StorageReplicatedMergeTree.cpp:5228: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl[abi:se190107] const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000015f9a5fe 17. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000015ed8bfd 18. /build/src/Storages/StorageReplicatedMergeTree.cpp:2514: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x0000000015ec9aab 19. /build/src/Storages/StorageReplicatedMergeTree.cpp:2349: DB::StorageReplicatedMergeTree::executeLogEntry(DB::ReplicatedMergeTreeLogEntry&) @ 0x0000000015eba91b 20. /build/src/Storages/StorageReplicatedMergeTree.cpp:3876: bool std::__function::__policy_invoker&)>::__call_impl[abi:se190107])::$_1, bool (std::shared_ptr&)>>(std::__function::__policy_storage const*, std::shared_ptr&) @ 0x0000000015f9837e 21. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000165d6fc3 22. /build/src/Storages/StorageReplicatedMergeTree.cpp:3872: DB::StorageReplicatedMergeTree::processQueueEntry(std::shared_ptr) @ 0x0000000015efc18a 23. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001624c1b2 24. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000162f9c70 25. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x00000000162fa55a 26. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc6653 27. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000000fccc4c3 28. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc3d92 29. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fcca080 30. ? @ 0x00007fbc6213eac3 31. ? @ 0x00007fbc621d0850 (version 25.3.6.10636.altinitytest (altinity build)) 2025.07.28 12:01:04.013085 [ 17255 ] {371d93ff-04f9-4a6d-8671-ec65e7a5a728} 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.6.10636.altinitytest (altinity build)) (from [::1]:55044) (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. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&) @ 0x000000000a10182b 4. /build/src/Planner/CollectTableExpressionData.cpp:272: DB::InDepthQueryTreeVisitor::visit(std::shared_ptr const&) @ 0x00000000142d02cd 5. /build/src/Analyzer/InDepthQueryTreeVisitor.h:90: DB::InDepthQueryTreeVisitor::visit(std::shared_ptr const&) @ 0x00000000142cffca 6. /build/src/Analyzer/InDepthQueryTreeVisitor.h:90: DB::InDepthQueryTreeVisitor::visit(std::shared_ptr const&) @ 0x00000000142cffca 7. /build/src/Planner/CollectTableExpressionData.cpp:364: DB::collectTableExpressionData(std::shared_ptr&, std::shared_ptr&) @ 0x00000000142cdf3f 8. /build/src/Planner/Planner.cpp:1486: DB::Planner::buildPlanForQueryNode() @ 0x0000000014978dec 9. /build/src/Planner/Planner.cpp:1308: DB::Planner::buildQueryPlanIfNeeded() @ 0x000000001497685c 10. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:255: DB::InterpreterSelectQueryAnalyzer::getQueryPlan() @ 0x000000001497476d 11. /build/src/Interpreters/executeQuery.cpp:1405: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88806 12. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 13. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 14. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 15. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 16. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 17. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 18. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 19. ? @ 0x00007fbc6213eac3 20. ? @ 0x00007fbc621d0850 2025.07.28 12:01:04.017259 [ 17255 ] {} 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. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&) @ 0x000000000a10182b 4. /build/src/Planner/CollectTableExpressionData.cpp:272: DB::InDepthQueryTreeVisitor::visit(std::shared_ptr const&) @ 0x00000000142d02cd 5. /build/src/Analyzer/InDepthQueryTreeVisitor.h:90: DB::InDepthQueryTreeVisitor::visit(std::shared_ptr const&) @ 0x00000000142cffca 6. /build/src/Analyzer/InDepthQueryTreeVisitor.h:90: DB::InDepthQueryTreeVisitor::visit(std::shared_ptr const&) @ 0x00000000142cffca 7. /build/src/Planner/CollectTableExpressionData.cpp:364: DB::collectTableExpressionData(std::shared_ptr&, std::shared_ptr&) @ 0x00000000142cdf3f 8. /build/src/Planner/Planner.cpp:1486: DB::Planner::buildPlanForQueryNode() @ 0x0000000014978dec 9. /build/src/Planner/Planner.cpp:1308: DB::Planner::buildQueryPlanIfNeeded() @ 0x000000001497685c 10. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:255: DB::InterpreterSelectQueryAnalyzer::getQueryPlan() @ 0x000000001497476d 11. /build/src/Interpreters/executeQuery.cpp:1405: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88806 12. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 13. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 14. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 15. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 16. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 17. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 18. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 19. ? @ 0x00007fbc6213eac3 20. ? @ 0x00007fbc621d0850 2025.07.28 12:01:04.431194 [ 3969 ] {} test_13.rmt2 (7f9b740d-015c-470e-8cc6-8ba33be0dc63): auto DB::StorageReplicatedMergeTree::processQueueEntry(ReplicatedMergeTreeQueue::SelectedEntryPtr)::(anonymous class)::operator()(LogEntryPtr &) const: Code: 86. DB::HTTPException: Received error from remote server http://146b4357c08d:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Ftest%2F01165%2Ftest_13%2Frmt%2Freplicas%2F1&part=20250728_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.6.10636.altinitytest (altinity build)) '. (RECEIVED_ERROR_FROM_REMOTE_IO_SERVER), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.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 const&, int&&, String const&, unsigned long&&, String const&) @ 0x000000000feda8d9 4. /build/src/IO/HTTPCommon.cpp:104: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x000000000feda6e2 5. /build/src/IO/HTTPCommon.cpp:93: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x000000000feda537 6. /build/src/IO/ReadWriteBufferFromHTTP.cpp:277: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x000000001184a4c4 7. /build/src/IO/ReadWriteBufferFromHTTP.cpp:285: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x000000001184a615 8. /build/src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x000000001184ae59 9. /build/src/IO/ReadWriteBufferFromHTTP.cpp:472: void std::__function::__policy_invoker::__call_impl[abi:se190107]>(std::__function::__policy_storage const*) @ 0x000000001184cedd 10. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001184858b 11. /build/src/IO/ReadWriteBufferFromHTTP.cpp:465: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x000000001184bf0b 12. /build/src/IO/ReadBuffer.h:60: DB::ReadBuffer::next() @ 0x000000000a148c7b 13. /build/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) @ 0x0000000011849fb2 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]>&)>&, 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&) @ 0x0000000011841980 15. /build/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) @ 0x000000001621208e 16. /build/src/Storages/StorageReplicatedMergeTree.cpp:5228: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl[abi:se190107] const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000015f9a5fe 17. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000015ed8bfd 18. /build/src/Storages/StorageReplicatedMergeTree.cpp:2514: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x0000000015ec9aab 19. /build/src/Storages/StorageReplicatedMergeTree.cpp:2349: DB::StorageReplicatedMergeTree::executeLogEntry(DB::ReplicatedMergeTreeLogEntry&) @ 0x0000000015eba91b 20. /build/src/Storages/StorageReplicatedMergeTree.cpp:3876: bool std::__function::__policy_invoker&)>::__call_impl[abi:se190107])::$_1, bool (std::shared_ptr&)>>(std::__function::__policy_storage const*, std::shared_ptr&) @ 0x0000000015f9837e 21. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000165d6fc3 22. /build/src/Storages/StorageReplicatedMergeTree.cpp:3872: DB::StorageReplicatedMergeTree::processQueueEntry(std::shared_ptr) @ 0x0000000015efc18a 23. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001624c1b2 24. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000162f9c70 25. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x00000000162fa55a 26. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc6653 27. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000000fccc4c3 28. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc3d92 29. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fcca080 30. ? @ 0x00007fbc6213eac3 31. ? @ 0x00007fbc621d0850 (version 25.3.6.10636.altinitytest (altinity build)) 2025.07.28 12:01:04.473898 [ 17255 ] {db85d368-fd9f-4e01-8e21-0c4a0118327d} 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 IN ('test_distributed_1', 'test_distributed_2') ORDER BY value ASC. (ILLEGAL_PREWHERE) (version 25.3.6.10636.altinitytest (altinity build)) (from [::1]:55044) (comment: 00717_merge_and_distributed.sql) (query 53, line 62) (in query: SELECT * FROM merge(currentDatabase(), 'test_distributed_1|test_distributed_2') PREWHERE _table in ('test_distributed_1', 'test_distributed_2') ORDER BY value;), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&) @ 0x000000000a10182b 4. /build/src/Planner/CollectTableExpressionData.cpp:272: DB::InDepthQueryTreeVisitor::visit(std::shared_ptr const&) @ 0x00000000142d02cd 5. /build/src/Analyzer/InDepthQueryTreeVisitor.h:90: DB::InDepthQueryTreeVisitor::visit(std::shared_ptr const&) @ 0x00000000142cffca 6. /build/src/Analyzer/InDepthQueryTreeVisitor.h:90: DB::InDepthQueryTreeVisitor::visit(std::shared_ptr const&) @ 0x00000000142cffca 7. /build/src/Planner/CollectTableExpressionData.cpp:364: DB::collectTableExpressionData(std::shared_ptr&, std::shared_ptr&) @ 0x00000000142cdf3f 8. /build/src/Planner/Planner.cpp:1486: DB::Planner::buildPlanForQueryNode() @ 0x0000000014978dec 9. /build/src/Planner/Planner.cpp:1308: DB::Planner::buildQueryPlanIfNeeded() @ 0x000000001497685c 10. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:255: DB::InterpreterSelectQueryAnalyzer::getQueryPlan() @ 0x000000001497476d 11. /build/src/Interpreters/executeQuery.cpp:1405: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88806 12. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 13. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 14. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 15. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 16. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 17. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 18. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 19. ? @ 0x00007fbc6213eac3 20. ? @ 0x00007fbc621d0850 2025.07.28 12:01:04.494068 [ 17255 ] {} 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 IN ('test_distributed_1', 'test_distributed_2') ORDER BY value ASC. (ILLEGAL_PREWHERE), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&) @ 0x000000000a10182b 4. /build/src/Planner/CollectTableExpressionData.cpp:272: DB::InDepthQueryTreeVisitor::visit(std::shared_ptr const&) @ 0x00000000142d02cd 5. /build/src/Analyzer/InDepthQueryTreeVisitor.h:90: DB::InDepthQueryTreeVisitor::visit(std::shared_ptr const&) @ 0x00000000142cffca 6. /build/src/Analyzer/InDepthQueryTreeVisitor.h:90: DB::InDepthQueryTreeVisitor::visit(std::shared_ptr const&) @ 0x00000000142cffca 7. /build/src/Planner/CollectTableExpressionData.cpp:364: DB::collectTableExpressionData(std::shared_ptr&, std::shared_ptr&) @ 0x00000000142cdf3f 8. /build/src/Planner/Planner.cpp:1486: DB::Planner::buildPlanForQueryNode() @ 0x0000000014978dec 9. /build/src/Planner/Planner.cpp:1308: DB::Planner::buildQueryPlanIfNeeded() @ 0x000000001497685c 10. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:255: DB::InterpreterSelectQueryAnalyzer::getQueryPlan() @ 0x000000001497476d 11. /build/src/Interpreters/executeQuery.cpp:1405: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88806 12. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 13. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 14. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 15. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 16. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 17. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 18. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 19. ? @ 0x00007fbc6213eac3 20. ? @ 0x00007fbc621d0850 2025.07.28 12:01:04.638497 [ 3964 ] {} test_13.rmt2 (7f9b740d-015c-470e-8cc6-8ba33be0dc63): auto DB::StorageReplicatedMergeTree::processQueueEntry(ReplicatedMergeTreeQueue::SelectedEntryPtr)::(anonymous class)::operator()(LogEntryPtr &) const: Code: 86. DB::HTTPException: Received error from remote server http://146b4357c08d:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Ftest%2F01165%2Ftest_13%2Frmt%2Freplicas%2F1&part=20250728_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.6.10636.altinitytest (altinity build)) '. (RECEIVED_ERROR_FROM_REMOTE_IO_SERVER), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.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 const&, int&&, String const&, unsigned long&&, String const&) @ 0x000000000feda8d9 4. /build/src/IO/HTTPCommon.cpp:104: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x000000000feda6e2 5. /build/src/IO/HTTPCommon.cpp:93: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x000000000feda537 6. /build/src/IO/ReadWriteBufferFromHTTP.cpp:277: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x000000001184a4c4 7. /build/src/IO/ReadWriteBufferFromHTTP.cpp:285: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x000000001184a615 8. /build/src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x000000001184ae59 9. /build/src/IO/ReadWriteBufferFromHTTP.cpp:472: void std::__function::__policy_invoker::__call_impl[abi:se190107]>(std::__function::__policy_storage const*) @ 0x000000001184cedd 10. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001184858b 11. /build/src/IO/ReadWriteBufferFromHTTP.cpp:465: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x000000001184bf0b 12. /build/src/IO/ReadBuffer.h:60: DB::ReadBuffer::next() @ 0x000000000a148c7b 13. /build/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) @ 0x0000000011849fb2 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]>&)>&, 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&) @ 0x0000000011841980 15. /build/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) @ 0x000000001621208e 16. /build/src/Storages/StorageReplicatedMergeTree.cpp:5228: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl[abi:se190107] const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000015f9a5fe 17. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000015ed8bfd 18. /build/src/Storages/StorageReplicatedMergeTree.cpp:2514: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x0000000015ec9aab 19. /build/src/Storages/StorageReplicatedMergeTree.cpp:2349: DB::StorageReplicatedMergeTree::executeLogEntry(DB::ReplicatedMergeTreeLogEntry&) @ 0x0000000015eba91b 20. /build/src/Storages/StorageReplicatedMergeTree.cpp:3876: bool std::__function::__policy_invoker&)>::__call_impl[abi:se190107])::$_1, bool (std::shared_ptr&)>>(std::__function::__policy_storage const*, std::shared_ptr&) @ 0x0000000015f9837e 21. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000165d6fc3 22. /build/src/Storages/StorageReplicatedMergeTree.cpp:3872: DB::StorageReplicatedMergeTree::processQueueEntry(std::shared_ptr) @ 0x0000000015efc18a 23. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001624c1b2 24. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000162f9c70 25. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x00000000162fa55a 26. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc6653 27. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000000fccc4c3 28. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc3d92 29. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fcca080 30. ? @ 0x00007fbc6213eac3 31. ? @ 0x00007fbc621d0850 (version 25.3.6.10636.altinitytest (altinity build)) 2025.07.28 12:01:05.203160 [ 3977 ] {} test_13.rmt2 (7f9b740d-015c-470e-8cc6-8ba33be0dc63): auto DB::StorageReplicatedMergeTree::processQueueEntry(ReplicatedMergeTreeQueue::SelectedEntryPtr)::(anonymous class)::operator()(LogEntryPtr &) const: Code: 86. DB::HTTPException: Received error from remote server http://146b4357c08d:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Ftest%2F01165%2Ftest_13%2Frmt%2Freplicas%2F1&part=20250728_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.6.10636.altinitytest (altinity build)) '. (RECEIVED_ERROR_FROM_REMOTE_IO_SERVER), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.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 const&, int&&, String const&, unsigned long&&, String const&) @ 0x000000000feda8d9 4. /build/src/IO/HTTPCommon.cpp:104: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x000000000feda6e2 5. /build/src/IO/HTTPCommon.cpp:93: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x000000000feda537 6. /build/src/IO/ReadWriteBufferFromHTTP.cpp:277: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x000000001184a4c4 7. /build/src/IO/ReadWriteBufferFromHTTP.cpp:285: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x000000001184a615 8. /build/src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x000000001184ae59 9. /build/src/IO/ReadWriteBufferFromHTTP.cpp:472: void std::__function::__policy_invoker::__call_impl[abi:se190107]>(std::__function::__policy_storage const*) @ 0x000000001184cedd 10. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001184858b 11. /build/src/IO/ReadWriteBufferFromHTTP.cpp:465: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x000000001184bf0b 12. /build/src/IO/ReadBuffer.h:60: DB::ReadBuffer::next() @ 0x000000000a148c7b 13. /build/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) @ 0x0000000011849fb2 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]>&)>&, 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&) @ 0x0000000011841980 15. /build/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) @ 0x000000001621208e 16. /build/src/Storages/StorageReplicatedMergeTree.cpp:5228: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl[abi:se190107] const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000015f9a5fe 17. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000015ed8bfd 18. /build/src/Storages/StorageReplicatedMergeTree.cpp:2514: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x0000000015ec9aab 19. /build/src/Storages/StorageReplicatedMergeTree.cpp:2349: DB::StorageReplicatedMergeTree::executeLogEntry(DB::ReplicatedMergeTreeLogEntry&) @ 0x0000000015eba91b 20. /build/src/Storages/StorageReplicatedMergeTree.cpp:3876: bool std::__function::__policy_invoker&)>::__call_impl[abi:se190107])::$_1, bool (std::shared_ptr&)>>(std::__function::__policy_storage const*, std::shared_ptr&) @ 0x0000000015f9837e 21. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000165d6fc3 22. /build/src/Storages/StorageReplicatedMergeTree.cpp:3872: DB::StorageReplicatedMergeTree::processQueueEntry(std::shared_ptr) @ 0x0000000015efc18a 23. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001624c1b2 24. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000162f9c70 25. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x00000000162fa55a 26. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc6653 27. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000000fccc4c3 28. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc3d92 29. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fcca080 30. ? @ 0x00007fbc6213eac3 31. ? @ 0x00007fbc621d0850 (version 25.3.6.10636.altinitytest (altinity build)) 2025.07.28 12:01:05.660864 [ 3971 ] {} test_13.rmt2 (7f9b740d-015c-470e-8cc6-8ba33be0dc63): auto DB::StorageReplicatedMergeTree::processQueueEntry(ReplicatedMergeTreeQueue::SelectedEntryPtr)::(anonymous class)::operator()(LogEntryPtr &) const: Code: 86. DB::HTTPException: Received error from remote server http://146b4357c08d:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Ftest%2F01165%2Ftest_13%2Frmt%2Freplicas%2F1&part=20250728_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.6.10636.altinitytest (altinity build)) '. (RECEIVED_ERROR_FROM_REMOTE_IO_SERVER), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.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 const&, int&&, String const&, unsigned long&&, String const&) @ 0x000000000feda8d9 4. /build/src/IO/HTTPCommon.cpp:104: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x000000000feda6e2 5. /build/src/IO/HTTPCommon.cpp:93: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x000000000feda537 6. /build/src/IO/ReadWriteBufferFromHTTP.cpp:277: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x000000001184a4c4 7. /build/src/IO/ReadWriteBufferFromHTTP.cpp:285: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x000000001184a615 8. /build/src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x000000001184ae59 9. /build/src/IO/ReadWriteBufferFromHTTP.cpp:472: void std::__function::__policy_invoker::__call_impl[abi:se190107]>(std::__function::__policy_storage const*) @ 0x000000001184cedd 10. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001184858b 11. /build/src/IO/ReadWriteBufferFromHTTP.cpp:465: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x000000001184bf0b 12. /build/src/IO/ReadBuffer.h:60: DB::ReadBuffer::next() @ 0x000000000a148c7b 13. /build/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) @ 0x0000000011849fb2 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]>&)>&, 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&) @ 0x0000000011841980 15. /build/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) @ 0x000000001621208e 16. /build/src/Storages/StorageReplicatedMergeTree.cpp:5228: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl[abi:se190107] const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000015f9a5fe 17. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000015ed8bfd 18. /build/src/Storages/StorageReplicatedMergeTree.cpp:2514: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x0000000015ec9aab 19. /build/src/Storages/StorageReplicatedMergeTree.cpp:2349: DB::StorageReplicatedMergeTree::executeLogEntry(DB::ReplicatedMergeTreeLogEntry&) @ 0x0000000015eba91b 20. /build/src/Storages/StorageReplicatedMergeTree.cpp:3876: bool std::__function::__policy_invoker&)>::__call_impl[abi:se190107])::$_1, bool (std::shared_ptr&)>>(std::__function::__policy_storage const*, std::shared_ptr&) @ 0x0000000015f9837e 21. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000165d6fc3 22. /build/src/Storages/StorageReplicatedMergeTree.cpp:3872: DB::StorageReplicatedMergeTree::processQueueEntry(std::shared_ptr) @ 0x0000000015efc18a 23. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001624c1b2 24. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000162f9c70 25. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x00000000162fa55a 26. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc6653 27. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000000fccc4c3 28. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc3d92 29. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fcca080 30. ? @ 0x00007fbc6213eac3 31. ? @ 0x00007fbc621d0850 (version 25.3.6.10636.altinitytest (altinity build)) 2025.07.28 12:01:06.316257 [ 3970 ] {} test_13.rmt2 (7f9b740d-015c-470e-8cc6-8ba33be0dc63): auto DB::StorageReplicatedMergeTree::processQueueEntry(ReplicatedMergeTreeQueue::SelectedEntryPtr)::(anonymous class)::operator()(LogEntryPtr &) const: Code: 86. DB::HTTPException: Received error from remote server http://146b4357c08d:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Ftest%2F01165%2Ftest_13%2Frmt%2Freplicas%2F1&part=20250728_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.6.10636.altinitytest (altinity build)) '. (RECEIVED_ERROR_FROM_REMOTE_IO_SERVER), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.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 const&, int&&, String const&, unsigned long&&, String const&) @ 0x000000000feda8d9 4. /build/src/IO/HTTPCommon.cpp:104: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x000000000feda6e2 5. /build/src/IO/HTTPCommon.cpp:93: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x000000000feda537 6. /build/src/IO/ReadWriteBufferFromHTTP.cpp:277: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x000000001184a4c4 7. /build/src/IO/ReadWriteBufferFromHTTP.cpp:285: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x000000001184a615 8. /build/src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x000000001184ae59 9. /build/src/IO/ReadWriteBufferFromHTTP.cpp:472: void std::__function::__policy_invoker::__call_impl[abi:se190107]>(std::__function::__policy_storage const*) @ 0x000000001184cedd 10. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001184858b 11. /build/src/IO/ReadWriteBufferFromHTTP.cpp:465: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x000000001184bf0b 12. /build/src/IO/ReadBuffer.h:60: DB::ReadBuffer::next() @ 0x000000000a148c7b 13. /build/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) @ 0x0000000011849fb2 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]>&)>&, 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&) @ 0x0000000011841980 15. /build/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) @ 0x000000001621208e 16. /build/src/Storages/StorageReplicatedMergeTree.cpp:5228: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl[abi:se190107] const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000015f9a5fe 17. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000015ed8bfd 18. /build/src/Storages/StorageReplicatedMergeTree.cpp:2514: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x0000000015ec9aab 19. /build/src/Storages/StorageReplicatedMergeTree.cpp:2349: DB::StorageReplicatedMergeTree::executeLogEntry(DB::ReplicatedMergeTreeLogEntry&) @ 0x0000000015eba91b 20. /build/src/Storages/StorageReplicatedMergeTree.cpp:3876: bool std::__function::__policy_invoker&)>::__call_impl[abi:se190107])::$_1, bool (std::shared_ptr&)>>(std::__function::__policy_storage const*, std::shared_ptr&) @ 0x0000000015f9837e 21. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000165d6fc3 22. /build/src/Storages/StorageReplicatedMergeTree.cpp:3872: DB::StorageReplicatedMergeTree::processQueueEntry(std::shared_ptr) @ 0x0000000015efc18a 23. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001624c1b2 24. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000162f9c70 25. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x00000000162fa55a 26. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc6653 27. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000000fccc4c3 28. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc3d92 29. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fcca080 30. ? @ 0x00007fbc6213eac3 31. ? @ 0x00007fbc621d0850 (version 25.3.6.10636.altinitytest (altinity build)) 2025.07.28 12:01:07.092944 [ 3968 ] {} test_13.rmt2 (7f9b740d-015c-470e-8cc6-8ba33be0dc63): auto DB::StorageReplicatedMergeTree::processQueueEntry(ReplicatedMergeTreeQueue::SelectedEntryPtr)::(anonymous class)::operator()(LogEntryPtr &) const: Code: 86. DB::HTTPException: Received error from remote server http://146b4357c08d:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Ftest%2F01165%2Ftest_13%2Frmt%2Freplicas%2F1&part=20250728_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.6.10636.altinitytest (altinity build)) '. (RECEIVED_ERROR_FROM_REMOTE_IO_SERVER), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.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 const&, int&&, String const&, unsigned long&&, String const&) @ 0x000000000feda8d9 4. /build/src/IO/HTTPCommon.cpp:104: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x000000000feda6e2 5. /build/src/IO/HTTPCommon.cpp:93: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x000000000feda537 6. /build/src/IO/ReadWriteBufferFromHTTP.cpp:277: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x000000001184a4c4 7. /build/src/IO/ReadWriteBufferFromHTTP.cpp:285: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x000000001184a615 8. /build/src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x000000001184ae59 9. /build/src/IO/ReadWriteBufferFromHTTP.cpp:472: void std::__function::__policy_invoker::__call_impl[abi:se190107]>(std::__function::__policy_storage const*) @ 0x000000001184cedd 10. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001184858b 11. /build/src/IO/ReadWriteBufferFromHTTP.cpp:465: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x000000001184bf0b 12. /build/src/IO/ReadBuffer.h:60: DB::ReadBuffer::next() @ 0x000000000a148c7b 13. /build/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) @ 0x0000000011849fb2 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]>&)>&, 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&) @ 0x0000000011841980 15. /build/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) @ 0x000000001621208e 16. /build/src/Storages/StorageReplicatedMergeTree.cpp:5228: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl[abi:se190107] const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000015f9a5fe 17. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000015ed8bfd 18. /build/src/Storages/StorageReplicatedMergeTree.cpp:2514: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x0000000015ec9aab 19. /build/src/Storages/StorageReplicatedMergeTree.cpp:2349: DB::StorageReplicatedMergeTree::executeLogEntry(DB::ReplicatedMergeTreeLogEntry&) @ 0x0000000015eba91b 20. /build/src/Storages/StorageReplicatedMergeTree.cpp:3876: bool std::__function::__policy_invoker&)>::__call_impl[abi:se190107])::$_1, bool (std::shared_ptr&)>>(std::__function::__policy_storage const*, std::shared_ptr&) @ 0x0000000015f9837e 21. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000165d6fc3 22. /build/src/Storages/StorageReplicatedMergeTree.cpp:3872: DB::StorageReplicatedMergeTree::processQueueEntry(std::shared_ptr) @ 0x0000000015efc18a 23. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001624c1b2 24. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000162f9c70 25. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x00000000162fa55a 26. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc6653 27. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000000fccc4c3 28. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc3d92 29. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fcca080 30. ? @ 0x00007fbc6213eac3 31. ? @ 0x00007fbc621d0850 (version 25.3.6.10636.altinitytest (altinity build)) 2025.07.28 12:01:07.934927 [ 3965 ] {} test_13.rmt2 (7f9b740d-015c-470e-8cc6-8ba33be0dc63): auto DB::StorageReplicatedMergeTree::processQueueEntry(ReplicatedMergeTreeQueue::SelectedEntryPtr)::(anonymous class)::operator()(LogEntryPtr &) const: Code: 86. DB::HTTPException: Received error from remote server http://146b4357c08d:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Ftest%2F01165%2Ftest_13%2Frmt%2Freplicas%2F1&part=20250728_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.6.10636.altinitytest (altinity build)) '. (RECEIVED_ERROR_FROM_REMOTE_IO_SERVER), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.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 const&, int&&, String const&, unsigned long&&, String const&) @ 0x000000000feda8d9 4. /build/src/IO/HTTPCommon.cpp:104: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x000000000feda6e2 5. /build/src/IO/HTTPCommon.cpp:93: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x000000000feda537 6. /build/src/IO/ReadWriteBufferFromHTTP.cpp:277: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x000000001184a4c4 7. /build/src/IO/ReadWriteBufferFromHTTP.cpp:285: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x000000001184a615 8. /build/src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x000000001184ae59 9. /build/src/IO/ReadWriteBufferFromHTTP.cpp:472: void std::__function::__policy_invoker::__call_impl[abi:se190107]>(std::__function::__policy_storage const*) @ 0x000000001184cedd 10. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001184858b 11. /build/src/IO/ReadWriteBufferFromHTTP.cpp:465: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x000000001184bf0b 12. /build/src/IO/ReadBuffer.h:60: DB::ReadBuffer::next() @ 0x000000000a148c7b 13. /build/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) @ 0x0000000011849fb2 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]>&)>&, 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&) @ 0x0000000011841980 15. /build/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) @ 0x000000001621208e 16. /build/src/Storages/StorageReplicatedMergeTree.cpp:5228: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl[abi:se190107] const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000015f9a5fe 17. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000015ed8bfd 18. /build/src/Storages/StorageReplicatedMergeTree.cpp:2514: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x0000000015ec9aab 19. /build/src/Storages/StorageReplicatedMergeTree.cpp:2349: DB::StorageReplicatedMergeTree::executeLogEntry(DB::ReplicatedMergeTreeLogEntry&) @ 0x0000000015eba91b 20. /build/src/Storages/StorageReplicatedMergeTree.cpp:3876: bool std::__function::__policy_invoker&)>::__call_impl[abi:se190107])::$_1, bool (std::shared_ptr&)>>(std::__function::__policy_storage const*, std::shared_ptr&) @ 0x0000000015f9837e 21. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000165d6fc3 22. /build/src/Storages/StorageReplicatedMergeTree.cpp:3872: DB::StorageReplicatedMergeTree::processQueueEntry(std::shared_ptr) @ 0x0000000015efc18a 23. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001624c1b2 24. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000162f9c70 25. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x00000000162fa55a 26. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc6653 27. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000000fccc4c3 28. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc3d92 29. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fcca080 30. ? @ 0x00007fbc6213eac3 31. ? @ 0x00007fbc621d0850 (version 25.3.6.10636.altinitytest (altinity build)) 2025.07.28 12:01:08.898235 [ 3974 ] {} test_13.rmt2 (7f9b740d-015c-470e-8cc6-8ba33be0dc63): auto DB::StorageReplicatedMergeTree::processQueueEntry(ReplicatedMergeTreeQueue::SelectedEntryPtr)::(anonymous class)::operator()(LogEntryPtr &) const: Code: 86. DB::HTTPException: Received error from remote server http://146b4357c08d:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Ftest%2F01165%2Ftest_13%2Frmt%2Freplicas%2F1&part=20250728_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.6.10636.altinitytest (altinity build)) '. (RECEIVED_ERROR_FROM_REMOTE_IO_SERVER), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.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 const&, int&&, String const&, unsigned long&&, String const&) @ 0x000000000feda8d9 4. /build/src/IO/HTTPCommon.cpp:104: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x000000000feda6e2 5. /build/src/IO/HTTPCommon.cpp:93: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x000000000feda537 6. /build/src/IO/ReadWriteBufferFromHTTP.cpp:277: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x000000001184a4c4 7. /build/src/IO/ReadWriteBufferFromHTTP.cpp:285: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x000000001184a615 8. /build/src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x000000001184ae59 9. /build/src/IO/ReadWriteBufferFromHTTP.cpp:472: void std::__function::__policy_invoker::__call_impl[abi:se190107]>(std::__function::__policy_storage const*) @ 0x000000001184cedd 10. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001184858b 11. /build/src/IO/ReadWriteBufferFromHTTP.cpp:465: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x000000001184bf0b 12. /build/src/IO/ReadBuffer.h:60: DB::ReadBuffer::next() @ 0x000000000a148c7b 13. /build/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) @ 0x0000000011849fb2 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]>&)>&, 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&) @ 0x0000000011841980 15. /build/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) @ 0x000000001621208e 16. /build/src/Storages/StorageReplicatedMergeTree.cpp:5228: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl[abi:se190107] const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000015f9a5fe 17. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000015ed8bfd 18. /build/src/Storages/StorageReplicatedMergeTree.cpp:2514: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x0000000015ec9aab 19. /build/src/Storages/StorageReplicatedMergeTree.cpp:2349: DB::StorageReplicatedMergeTree::executeLogEntry(DB::ReplicatedMergeTreeLogEntry&) @ 0x0000000015eba91b 20. /build/src/Storages/StorageReplicatedMergeTree.cpp:3876: bool std::__function::__policy_invoker&)>::__call_impl[abi:se190107])::$_1, bool (std::shared_ptr&)>>(std::__function::__policy_storage const*, std::shared_ptr&) @ 0x0000000015f9837e 21. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000165d6fc3 22. /build/src/Storages/StorageReplicatedMergeTree.cpp:3872: DB::StorageReplicatedMergeTree::processQueueEntry(std::shared_ptr) @ 0x0000000015efc18a 23. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001624c1b2 24. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000162f9c70 25. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x00000000162fa55a 26. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc6653 27. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000000fccc4c3 28. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc3d92 29. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fcca080 30. ? @ 0x00007fbc6213eac3 31. ? @ 0x00007fbc621d0850 (version 25.3.6.10636.altinitytest (altinity build)) 2025.07.28 12:01:09.877055 [ 3969 ] {} test_13.rmt2 (7f9b740d-015c-470e-8cc6-8ba33be0dc63): auto DB::StorageReplicatedMergeTree::processQueueEntry(ReplicatedMergeTreeQueue::SelectedEntryPtr)::(anonymous class)::operator()(LogEntryPtr &) const: Code: 86. DB::HTTPException: Received error from remote server http://146b4357c08d:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Ftest%2F01165%2Ftest_13%2Frmt%2Freplicas%2F1&part=20250728_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.6.10636.altinitytest (altinity build)) '. (RECEIVED_ERROR_FROM_REMOTE_IO_SERVER), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.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 const&, int&&, String const&, unsigned long&&, String const&) @ 0x000000000feda8d9 4. /build/src/IO/HTTPCommon.cpp:104: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x000000000feda6e2 5. /build/src/IO/HTTPCommon.cpp:93: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x000000000feda537 6. /build/src/IO/ReadWriteBufferFromHTTP.cpp:277: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x000000001184a4c4 7. /build/src/IO/ReadWriteBufferFromHTTP.cpp:285: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x000000001184a615 8. /build/src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x000000001184ae59 9. /build/src/IO/ReadWriteBufferFromHTTP.cpp:472: void std::__function::__policy_invoker::__call_impl[abi:se190107]>(std::__function::__policy_storage const*) @ 0x000000001184cedd 10. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001184858b 11. /build/src/IO/ReadWriteBufferFromHTTP.cpp:465: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x000000001184bf0b 12. /build/src/IO/ReadBuffer.h:60: DB::ReadBuffer::next() @ 0x000000000a148c7b 13. /build/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) @ 0x0000000011849fb2 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]>&)>&, 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&) @ 0x0000000011841980 15. /build/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) @ 0x000000001621208e 16. /build/src/Storages/StorageReplicatedMergeTree.cpp:5228: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl[abi:se190107] const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000015f9a5fe 17. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000015ed8bfd 18. /build/src/Storages/StorageReplicatedMergeTree.cpp:2514: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x0000000015ec9aab 19. /build/src/Storages/StorageReplicatedMergeTree.cpp:2349: DB::StorageReplicatedMergeTree::executeLogEntry(DB::ReplicatedMergeTreeLogEntry&) @ 0x0000000015eba91b 20. /build/src/Storages/StorageReplicatedMergeTree.cpp:3876: bool std::__function::__policy_invoker&)>::__call_impl[abi:se190107])::$_1, bool (std::shared_ptr&)>>(std::__function::__policy_storage const*, std::shared_ptr&) @ 0x0000000015f9837e 21. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000165d6fc3 22. /build/src/Storages/StorageReplicatedMergeTree.cpp:3872: DB::StorageReplicatedMergeTree::processQueueEntry(std::shared_ptr) @ 0x0000000015efc18a 23. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001624c1b2 24. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000162f9c70 25. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x00000000162fa55a 26. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc6653 27. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000000fccc4c3 28. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc3d92 29. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fcca080 30. ? @ 0x00007fbc6213eac3 31. ? @ 0x00007fbc621d0850 (version 25.3.6.10636.altinitytest (altinity build)) 2025.07.28 12:01:10.812644 [ 3967 ] {} test_13.rmt2 (7f9b740d-015c-470e-8cc6-8ba33be0dc63): auto DB::StorageReplicatedMergeTree::processQueueEntry(ReplicatedMergeTreeQueue::SelectedEntryPtr)::(anonymous class)::operator()(LogEntryPtr &) const: Code: 86. DB::HTTPException: Received error from remote server http://146b4357c08d:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Ftest%2F01165%2Ftest_13%2Frmt%2Freplicas%2F1&part=20250728_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.6.10636.altinitytest (altinity build)) '. (RECEIVED_ERROR_FROM_REMOTE_IO_SERVER), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.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 const&, int&&, String const&, unsigned long&&, String const&) @ 0x000000000feda8d9 4. /build/src/IO/HTTPCommon.cpp:104: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x000000000feda6e2 5. /build/src/IO/HTTPCommon.cpp:93: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x000000000feda537 6. /build/src/IO/ReadWriteBufferFromHTTP.cpp:277: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x000000001184a4c4 7. /build/src/IO/ReadWriteBufferFromHTTP.cpp:285: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x000000001184a615 8. /build/src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x000000001184ae59 9. /build/src/IO/ReadWriteBufferFromHTTP.cpp:472: void std::__function::__policy_invoker::__call_impl[abi:se190107]>(std::__function::__policy_storage const*) @ 0x000000001184cedd 10. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001184858b 11. /build/src/IO/ReadWriteBufferFromHTTP.cpp:465: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x000000001184bf0b 12. /build/src/IO/ReadBuffer.h:60: DB::ReadBuffer::next() @ 0x000000000a148c7b 13. /build/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) @ 0x0000000011849fb2 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]>&)>&, 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&) @ 0x0000000011841980 15. /build/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) @ 0x000000001621208e 16. /build/src/Storages/StorageReplicatedMergeTree.cpp:5228: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl[abi:se190107] const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000015f9a5fe 17. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000015ed8bfd 18. /build/src/Storages/StorageReplicatedMergeTree.cpp:2514: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x0000000015ec9aab 19. /build/src/Storages/StorageReplicatedMergeTree.cpp:2349: DB::StorageReplicatedMergeTree::executeLogEntry(DB::ReplicatedMergeTreeLogEntry&) @ 0x0000000015eba91b 20. /build/src/Storages/StorageReplicatedMergeTree.cpp:3876: bool std::__function::__policy_invoker&)>::__call_impl[abi:se190107])::$_1, bool (std::shared_ptr&)>>(std::__function::__policy_storage const*, std::shared_ptr&) @ 0x0000000015f9837e 21. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000165d6fc3 22. /build/src/Storages/StorageReplicatedMergeTree.cpp:3872: DB::StorageReplicatedMergeTree::processQueueEntry(std::shared_ptr) @ 0x0000000015efc18a 23. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001624c1b2 24. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000162f9c70 25. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x00000000162fa55a 26. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc6653 27. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000000fccc4c3 28. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc3d92 29. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fcca080 30. ? @ 0x00007fbc6213eac3 31. ? @ 0x00007fbc621d0850 (version 25.3.6.10636.altinitytest (altinity build)) 2025.07.28 12:01:10.981665 [ 3965 ] {} test_13.rmt2 (7f9b740d-015c-470e-8cc6-8ba33be0dc63): auto DB::StorageReplicatedMergeTree::processQueueEntry(ReplicatedMergeTreeQueue::SelectedEntryPtr)::(anonymous class)::operator()(LogEntryPtr &) const: Code: 86. DB::HTTPException: Received error from remote server http://146b4357c08d:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Ftest%2F01165%2Ftest_13%2Frmt%2Freplicas%2F1&part=20250728_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.6.10636.altinitytest (altinity build)) '. (RECEIVED_ERROR_FROM_REMOTE_IO_SERVER), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.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 const&, int&&, String const&, unsigned long&&, String const&) @ 0x000000000feda8d9 4. /build/src/IO/HTTPCommon.cpp:104: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x000000000feda6e2 5. /build/src/IO/HTTPCommon.cpp:93: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x000000000feda537 6. /build/src/IO/ReadWriteBufferFromHTTP.cpp:277: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x000000001184a4c4 7. /build/src/IO/ReadWriteBufferFromHTTP.cpp:285: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x000000001184a615 8. /build/src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x000000001184ae59 9. /build/src/IO/ReadWriteBufferFromHTTP.cpp:472: void std::__function::__policy_invoker::__call_impl[abi:se190107]>(std::__function::__policy_storage const*) @ 0x000000001184cedd 10. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001184858b 11. /build/src/IO/ReadWriteBufferFromHTTP.cpp:465: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x000000001184bf0b 12. /build/src/IO/ReadBuffer.h:60: DB::ReadBuffer::next() @ 0x000000000a148c7b 13. /build/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) @ 0x0000000011849fb2 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]>&)>&, 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&) @ 0x0000000011841980 15. /build/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) @ 0x000000001621208e 16. /build/src/Storages/StorageReplicatedMergeTree.cpp:5228: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl[abi:se190107] const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000015f9a5fe 17. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000015ed8bfd 18. /build/src/Storages/StorageReplicatedMergeTree.cpp:2514: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x0000000015ec9aab 19. /build/src/Storages/StorageReplicatedMergeTree.cpp:2349: DB::StorageReplicatedMergeTree::executeLogEntry(DB::ReplicatedMergeTreeLogEntry&) @ 0x0000000015eba91b 20. /build/src/Storages/StorageReplicatedMergeTree.cpp:3876: bool std::__function::__policy_invoker&)>::__call_impl[abi:se190107])::$_1, bool (std::shared_ptr&)>>(std::__function::__policy_storage const*, std::shared_ptr&) @ 0x0000000015f9837e 21. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000165d6fc3 22. /build/src/Storages/StorageReplicatedMergeTree.cpp:3872: DB::StorageReplicatedMergeTree::processQueueEntry(std::shared_ptr) @ 0x0000000015efc18a 23. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001624c1b2 24. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000162f9c70 25. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x00000000162fa55a 26. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc6653 27. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000000fccc4c3 28. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc3d92 29. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fcca080 30. ? @ 0x00007fbc6213eac3 31. ? @ 0x00007fbc621d0850 (version 25.3.6.10636.altinitytest (altinity build)) 2025.07.28 12:01:11.463438 [ 3970 ] {} test_13.rmt2 (7f9b740d-015c-470e-8cc6-8ba33be0dc63): auto DB::StorageReplicatedMergeTree::processQueueEntry(ReplicatedMergeTreeQueue::SelectedEntryPtr)::(anonymous class)::operator()(LogEntryPtr &) const: Code: 86. DB::HTTPException: Received error from remote server http://146b4357c08d:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Ftest%2F01165%2Ftest_13%2Frmt%2Freplicas%2F1&part=20250728_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.6.10636.altinitytest (altinity build)) '. (RECEIVED_ERROR_FROM_REMOTE_IO_SERVER), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.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 const&, int&&, String const&, unsigned long&&, String const&) @ 0x000000000feda8d9 4. /build/src/IO/HTTPCommon.cpp:104: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x000000000feda6e2 5. /build/src/IO/HTTPCommon.cpp:93: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x000000000feda537 6. /build/src/IO/ReadWriteBufferFromHTTP.cpp:277: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x000000001184a4c4 7. /build/src/IO/ReadWriteBufferFromHTTP.cpp:285: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x000000001184a615 8. /build/src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x000000001184ae59 9. /build/src/IO/ReadWriteBufferFromHTTP.cpp:472: void std::__function::__policy_invoker::__call_impl[abi:se190107]>(std::__function::__policy_storage const*) @ 0x000000001184cedd 10. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001184858b 11. /build/src/IO/ReadWriteBufferFromHTTP.cpp:465: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x000000001184bf0b 12. /build/src/IO/ReadBuffer.h:60: DB::ReadBuffer::next() @ 0x000000000a148c7b 13. /build/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) @ 0x0000000011849fb2 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]>&)>&, 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&) @ 0x0000000011841980 15. /build/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) @ 0x000000001621208e 16. /build/src/Storages/StorageReplicatedMergeTree.cpp:5228: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl[abi:se190107] const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000015f9a5fe 17. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000015ed8bfd 18. /build/src/Storages/StorageReplicatedMergeTree.cpp:2514: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x0000000015ec9aab 19. /build/src/Storages/StorageReplicatedMergeTree.cpp:2349: DB::StorageReplicatedMergeTree::executeLogEntry(DB::ReplicatedMergeTreeLogEntry&) @ 0x0000000015eba91b 20. /build/src/Storages/StorageReplicatedMergeTree.cpp:3876: bool std::__function::__policy_invoker&)>::__call_impl[abi:se190107])::$_1, bool (std::shared_ptr&)>>(std::__function::__policy_storage const*, std::shared_ptr&) @ 0x0000000015f9837e 21. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000165d6fc3 22. /build/src/Storages/StorageReplicatedMergeTree.cpp:3872: DB::StorageReplicatedMergeTree::processQueueEntry(std::shared_ptr) @ 0x0000000015efc18a 23. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001624c1b2 24. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000162f9c70 25. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x00000000162fa55a 26. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc6653 27. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000000fccc4c3 28. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc3d92 29. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fcca080 30. ? @ 0x00007fbc6213eac3 31. ? @ 0x00007fbc621d0850 (version 25.3.6.10636.altinitytest (altinity build)) 2025.07.28 12:01:12.153100 [ 7625 ] {71431555-404e-4afa-9f69-19ebf4d8105d} executeQuery: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(equals(__table1.number, 1000_UInt16) :: 0) -> throwIf(equals(__table1.number, 1000_UInt16)) UInt8 : 1'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO) (version 25.3.6.10636.altinitytest (altinity build)) (from [::1]:43402) (comment: 00602_throw_if.sh) (query 1, line 1) (in query: SELECT throwIf(number = 1000) FROM system.numbers), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x000000000a06b56b 4. /build/src/Functions/throwIf.cpp:153: DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000e8193b5 5. /build/src/Functions/IFunctionAdaptors.cpp:10: DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000012d995fa 6. /build/src/Functions/IFunction.cpp:353: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d93b52 7. /build/src/Functions/IFunction.cpp:420: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d95059 8. /build/src/Functions/IFunction.cpp:498: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d95c72 9. /build/src/Interpreters/ExpressionActions.cpp:636: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x00000000145176f3 10. /build/src/Processors/Transforms/ExpressionTransform.cpp:25: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x0000000016c0b34c 11. /build/src/Processors/ISimpleTransform.h:33: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000011a9a453 12. /build/src/Processors/ISimpleTransform.cpp:89: DB::ISimpleTransform::work() @ 0x000000001699fca0 13. /build/src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x00000000169bd00f 14. /build/src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x00000000169b2105 15. /build/src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeSingleThread(unsigned long) @ 0x00000000169b23be 16. /build/src/Processors/Executors/PipelineExecutor.cpp:454: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x00000000169b0be7 17. /build/src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x00000000169b03f4 18. /build/src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:se190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169bfeab 19. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc3d92 20. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fcca080 21. ? @ 0x00007fbc6213eac3 22. ? @ 0x00007fbc621d0850 2025.07.28 12:01:12.235554 [ 7625 ] {} TCPHandler: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(equals(__table1.number, 1000_UInt16) :: 0) -> throwIf(equals(__table1.number, 1000_UInt16)) UInt8 : 1'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x000000000a06b56b 4. /build/src/Functions/throwIf.cpp:153: DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000e8193b5 5. /build/src/Functions/IFunctionAdaptors.cpp:10: DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000012d995fa 6. /build/src/Functions/IFunction.cpp:353: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d93b52 7. /build/src/Functions/IFunction.cpp:420: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d95059 8. /build/src/Functions/IFunction.cpp:498: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d95c72 9. /build/src/Interpreters/ExpressionActions.cpp:636: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x00000000145176f3 10. /build/src/Processors/Transforms/ExpressionTransform.cpp:25: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x0000000016c0b34c 11. /build/src/Processors/ISimpleTransform.h:33: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000011a9a453 12. /build/src/Processors/ISimpleTransform.cpp:89: DB::ISimpleTransform::work() @ 0x000000001699fca0 13. /build/src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x00000000169bd00f 14. /build/src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x00000000169b2105 15. /build/src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeSingleThread(unsigned long) @ 0x00000000169b23be 16. /build/src/Processors/Executors/PipelineExecutor.cpp:454: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x00000000169b0be7 17. /build/src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x00000000169b03f4 18. /build/src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:se190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169bfeab 19. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc3d92 20. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fcca080 21. ? @ 0x00007fbc6213eac3 22. ? @ 0x00007fbc621d0850 Job's origin stack trace: 0. /build/src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000000fc33b84 1. /build/src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000000fcc2ea7 2. /build/src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fcc535c 3. /build/src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000000fcc584d 4. /build/src/Common/ThreadPool.h:279: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x00000000169bf193 5. /build/src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x00000000169bf518 6. /build/src/Server/TCPHandler.cpp:1237: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x00000000168f1525 7. /build/src/Server/TCPHandler.cpp:678: DB::TCPHandler::runImpl() @ 0x00000000168e68e5 8. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 9. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 10. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 11. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 12. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 13. ? @ 0x00007fbc6213eac3 14. ? @ 0x00007fbc621d0850 2025.07.28 12:01:12.345513 [ 3972 ] {} test_13.rmt2 (7f9b740d-015c-470e-8cc6-8ba33be0dc63): auto DB::StorageReplicatedMergeTree::processQueueEntry(ReplicatedMergeTreeQueue::SelectedEntryPtr)::(anonymous class)::operator()(LogEntryPtr &) const: Code: 86. DB::HTTPException: Received error from remote server http://146b4357c08d:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Ftest%2F01165%2Ftest_13%2Frmt%2Freplicas%2F1&part=20250728_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.6.10636.altinitytest (altinity build)) '. (RECEIVED_ERROR_FROM_REMOTE_IO_SERVER), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.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 const&, int&&, String const&, unsigned long&&, String const&) @ 0x000000000feda8d9 4. /build/src/IO/HTTPCommon.cpp:104: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x000000000feda6e2 5. /build/src/IO/HTTPCommon.cpp:93: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x000000000feda537 6. /build/src/IO/ReadWriteBufferFromHTTP.cpp:277: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x000000001184a4c4 7. /build/src/IO/ReadWriteBufferFromHTTP.cpp:285: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x000000001184a615 8. /build/src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x000000001184ae59 9. /build/src/IO/ReadWriteBufferFromHTTP.cpp:472: void std::__function::__policy_invoker::__call_impl[abi:se190107]>(std::__function::__policy_storage const*) @ 0x000000001184cedd 10. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001184858b 11. /build/src/IO/ReadWriteBufferFromHTTP.cpp:465: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x000000001184bf0b 12. /build/src/IO/ReadBuffer.h:60: DB::ReadBuffer::next() @ 0x000000000a148c7b 13. /build/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) @ 0x0000000011849fb2 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]>&)>&, 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&) @ 0x0000000011841980 15. /build/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) @ 0x000000001621208e 16. /build/src/Storages/StorageReplicatedMergeTree.cpp:5228: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl[abi:se190107] const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000015f9a5fe 17. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000015ed8bfd 18. /build/src/Storages/StorageReplicatedMergeTree.cpp:2514: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x0000000015ec9aab 19. /build/src/Storages/StorageReplicatedMergeTree.cpp:2349: DB::StorageReplicatedMergeTree::executeLogEntry(DB::ReplicatedMergeTreeLogEntry&) @ 0x0000000015eba91b 20. /build/src/Storages/StorageReplicatedMergeTree.cpp:3876: bool std::__function::__policy_invoker&)>::__call_impl[abi:se190107])::$_1, bool (std::shared_ptr&)>>(std::__function::__policy_storage const*, std::shared_ptr&) @ 0x0000000015f9837e 21. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000165d6fc3 22. /build/src/Storages/StorageReplicatedMergeTree.cpp:3872: DB::StorageReplicatedMergeTree::processQueueEntry(std::shared_ptr) @ 0x0000000015efc18a 23. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001624c1b2 24. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000162f9c70 25. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x00000000162fa55a 26. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc6653 27. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000000fccc4c3 28. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc3d92 29. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fcca080 30. ? @ 0x00007fbc6213eac3 31. ? @ 0x00007fbc621d0850 (version 25.3.6.10636.altinitytest (altinity build)) 2025.07.28 12:01:12.440497 [ 5951 ] {5fc9dad2-8a89-4994-937b-52a61380457a} executeQuery: Code: 395. DB::Exception: Number equals 1000: while executing 'FUNCTION throwIf(equals(__table1.number, 1000_UInt16) :: 0, 'Number equals 1000'_String :: 2) -> throwIf(equals(__table1.number, 1000_UInt16), 'Number equals 1000'_String) UInt8 : 1'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO) (version 25.3.6.10636.altinitytest (altinity build)) (from [::1]:43410) (comment: 00602_throw_if.sh) (query 1, line 1) (in query: SELECT throwIf(number = 1000, 'Number equals 1000') FROM system.numbers), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:111: DB::Exception::createRuntime(int, String const&) @ 0x000000000e81b22c 3. /build/src/Functions/throwIf.cpp:150: DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000e8194d8 4. /build/src/Functions/IFunctionAdaptors.cpp:10: DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000012d995fa 5. /build/src/Functions/IFunction.cpp:353: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d93b52 6. /build/src/Functions/IFunction.cpp:420: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d95059 7. /build/src/Functions/IFunction.cpp:498: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d95c72 8. /build/src/Interpreters/ExpressionActions.cpp:636: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x00000000145176f3 9. /build/src/Processors/Transforms/ExpressionTransform.cpp:25: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x0000000016c0b34c 10. /build/src/Processors/ISimpleTransform.h:33: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000011a9a453 11. /build/src/Processors/ISimpleTransform.cpp:89: DB::ISimpleTransform::work() @ 0x000000001699fca0 12. /build/src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x00000000169bd00f 13. /build/src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x00000000169b2105 14. /build/src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeSingleThread(unsigned long) @ 0x00000000169b23be 15. /build/src/Processors/Executors/PipelineExecutor.cpp:454: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x00000000169b0be7 16. /build/src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x00000000169b03f4 17. /build/src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:se190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169bfeab 18. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc3d92 19. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fcca080 20. ? @ 0x00007fbc6213eac3 21. ? @ 0x00007fbc621d0850 2025.07.28 12:01:12.470856 [ 5951 ] {} TCPHandler: Code: 395. DB::Exception: Number equals 1000: while executing 'FUNCTION throwIf(equals(__table1.number, 1000_UInt16) :: 0, 'Number equals 1000'_String :: 2) -> throwIf(equals(__table1.number, 1000_UInt16), 'Number equals 1000'_String) UInt8 : 1'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:111: DB::Exception::createRuntime(int, String const&) @ 0x000000000e81b22c 3. /build/src/Functions/throwIf.cpp:150: DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000e8194d8 4. /build/src/Functions/IFunctionAdaptors.cpp:10: DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000012d995fa 5. /build/src/Functions/IFunction.cpp:353: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d93b52 6. /build/src/Functions/IFunction.cpp:420: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d95059 7. /build/src/Functions/IFunction.cpp:498: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d95c72 8. /build/src/Interpreters/ExpressionActions.cpp:636: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x00000000145176f3 9. /build/src/Processors/Transforms/ExpressionTransform.cpp:25: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x0000000016c0b34c 10. /build/src/Processors/ISimpleTransform.h:33: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000011a9a453 11. /build/src/Processors/ISimpleTransform.cpp:89: DB::ISimpleTransform::work() @ 0x000000001699fca0 12. /build/src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x00000000169bd00f 13. /build/src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x00000000169b2105 14. /build/src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeSingleThread(unsigned long) @ 0x00000000169b23be 15. /build/src/Processors/Executors/PipelineExecutor.cpp:454: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x00000000169b0be7 16. /build/src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x00000000169b03f4 17. /build/src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:se190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169bfeab 18. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc3d92 19. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fcca080 20. ? @ 0x00007fbc6213eac3 21. ? @ 0x00007fbc621d0850 Job's origin stack trace: 0. /build/src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000000fc33b84 1. /build/src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000000fcc2ea7 2. /build/src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fcc535c 3. /build/src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000000fcc584d 4. /build/src/Common/ThreadPool.h:279: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x00000000169bf193 5. /build/src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x00000000169bf518 6. /build/src/Server/TCPHandler.cpp:1237: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x00000000168f1525 7. /build/src/Server/TCPHandler.cpp:678: DB::TCPHandler::runImpl() @ 0x00000000168e68e5 8. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 9. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 10. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 11. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 12. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 13. ? @ 0x00007fbc6213eac3 14. ? @ 0x00007fbc621d0850 2025.07.28 12:01:12.958739 [ 5951 ] {6ba3b948-6e05-4eba-aa58-c09f61af9614} 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(number = 1000, 'Number equals 1000', 1) FROM system.numbers. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.6.10636.altinitytest (altinity build)) (from [::1]:43422) (comment: 00602_throw_if.sh) (query 1, line 1) (in query: SELECT throwIf(number = 1000, 'Number equals 1000', 1) FROM system.numbers), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, unsigned long const&, char const*&&) @ 0x000000000e81b30b 4. /build/src/Functions/throwIf.cpp:53: DB::(anonymous namespace)::FunctionThrowIf::getReturnTypeImpl(std::vector, std::allocator>> const&) const @ 0x000000000e819fff 5. /build/src/Functions/IFunction.h:520: DB::IFunction::getReturnTypeImpl(std::vector> const&) const @ 0x000000000a06a2de 6. /build/src/Functions/IFunction.cpp:645: DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x0000000012d96b0c 7. /build/src/Functions/IFunction.cpp:577: DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x0000000012d9669c 8. /build/src/Functions/IFunction.cpp:606: DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x0000000012d96edc 9. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3544: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000014033cc9 10. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3838: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000014019a9e 11. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3980: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000014018e31 12. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:4304: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000014042fa7 13. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5605: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000014013749 14. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000140127f9 15. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000014011fce 16. /build/src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000001406ce8a 17. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000014973b42 18. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000001497268d 19. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000014974d24 20. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001492924b 21. /build/src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88641 22. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 23. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 24. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 25. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 26. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 27. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 28. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 29. ? @ 0x00007fbc6213eac3 30. ? @ 0x00007fbc621d0850 2025.07.28 12:01:12.972935 [ 5951 ] {} 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(number = 1000, 'Number equals 1000', 1) FROM system.numbers. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, unsigned long const&, char const*&&) @ 0x000000000e81b30b 4. /build/src/Functions/throwIf.cpp:53: DB::(anonymous namespace)::FunctionThrowIf::getReturnTypeImpl(std::vector, std::allocator>> const&) const @ 0x000000000e819fff 5. /build/src/Functions/IFunction.h:520: DB::IFunction::getReturnTypeImpl(std::vector> const&) const @ 0x000000000a06a2de 6. /build/src/Functions/IFunction.cpp:645: DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x0000000012d96b0c 7. /build/src/Functions/IFunction.cpp:577: DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x0000000012d9669c 8. /build/src/Functions/IFunction.cpp:606: DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x0000000012d96edc 9. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3544: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000014033cc9 10. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3838: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000014019a9e 11. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3980: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000014018e31 12. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:4304: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000014042fa7 13. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5605: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000014013749 14. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000140127f9 15. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000014011fce 16. /build/src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000001406ce8a 17. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000014973b42 18. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000001497268d 19. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000014974d24 20. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001492924b 21. /build/src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88641 22. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 23. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 24. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 25. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 26. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 27. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 28. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 29. ? @ 0x00007fbc6213eac3 30. ? @ 0x00007fbc621d0850 2025.07.28 12:01:13.082565 [ 3961 ] {} test_13.rmt2 (7f9b740d-015c-470e-8cc6-8ba33be0dc63): auto DB::StorageReplicatedMergeTree::processQueueEntry(ReplicatedMergeTreeQueue::SelectedEntryPtr)::(anonymous class)::operator()(LogEntryPtr &) const: Code: 86. DB::HTTPException: Received error from remote server http://146b4357c08d:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Ftest%2F01165%2Ftest_13%2Frmt%2Freplicas%2F1&part=20250728_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.6.10636.altinitytest (altinity build)) '. (RECEIVED_ERROR_FROM_REMOTE_IO_SERVER), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.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 const&, int&&, String const&, unsigned long&&, String const&) @ 0x000000000feda8d9 4. /build/src/IO/HTTPCommon.cpp:104: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x000000000feda6e2 5. /build/src/IO/HTTPCommon.cpp:93: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x000000000feda537 6. /build/src/IO/ReadWriteBufferFromHTTP.cpp:277: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x000000001184a4c4 7. /build/src/IO/ReadWriteBufferFromHTTP.cpp:285: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x000000001184a615 8. /build/src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x000000001184ae59 9. /build/src/IO/ReadWriteBufferFromHTTP.cpp:472: void std::__function::__policy_invoker::__call_impl[abi:se190107]>(std::__function::__policy_storage const*) @ 0x000000001184cedd 10. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001184858b 11. /build/src/IO/ReadWriteBufferFromHTTP.cpp:465: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x000000001184bf0b 12. /build/src/IO/ReadBuffer.h:60: DB::ReadBuffer::next() @ 0x000000000a148c7b 13. /build/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) @ 0x0000000011849fb2 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]>&)>&, 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&) @ 0x0000000011841980 15. /build/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) @ 0x000000001621208e 16. /build/src/Storages/StorageReplicatedMergeTree.cpp:5228: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl[abi:se190107] const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000015f9a5fe 17. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000015ed8bfd 18. /build/src/Storages/StorageReplicatedMergeTree.cpp:2514: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x0000000015ec9aab 19. /build/src/Storages/StorageReplicatedMergeTree.cpp:2349: DB::StorageReplicatedMergeTree::executeLogEntry(DB::ReplicatedMergeTreeLogEntry&) @ 0x0000000015eba91b 20. /build/src/Storages/StorageReplicatedMergeTree.cpp:3876: bool std::__function::__policy_invoker&)>::__call_impl[abi:se190107])::$_1, bool (std::shared_ptr&)>>(std::__function::__policy_storage const*, std::shared_ptr&) @ 0x0000000015f9837e 21. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000165d6fc3 22. /build/src/Storages/StorageReplicatedMergeTree.cpp:3872: DB::StorageReplicatedMergeTree::processQueueEntry(std::shared_ptr) @ 0x0000000015efc18a 23. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001624c1b2 24. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000162f9c70 25. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x00000000162fa55a 26. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc6653 27. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000000fccc4c3 28. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc3d92 29. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fcca080 30. ? @ 0x00007fbc6213eac3 31. ? @ 0x00007fbc621d0850 (version 25.3.6.10636.altinitytest (altinity build)) 2025.07.28 12:01:13.265638 [ 17611 ] {3fc59154-c3e8-4959-9855-a83557a74d86} executeQuery: Code: 43. DB::Exception: Third argument of function throwIf must be Int8, Int16 or Int32 (passed: UInt8): In scope SELECT throwIf(number = 1000, 'Number equals 1000', 1) FROM system.numbers SETTINGS allow_custom_error_code_in_throwif = true. (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.6.10636.altinitytest (altinity build)) (from [::1]:43440) (comment: 00602_throw_if.sh) (query 1, line 1) (in query: SELECT throwIf(number = 1000, 'Number equals 1000', 1) FROM system.numbers SETTINGS allow_custom_error_code_in_throwif=true), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000a06a8eb 4. /build/src/Functions/throwIf.cpp:69: DB::(anonymous namespace)::FunctionThrowIf::getReturnTypeImpl(std::vector, std::allocator>> const&) const @ 0x000000000e81a20e 5. /build/src/Functions/IFunction.h:520: DB::IFunction::getReturnTypeImpl(std::vector> const&) const @ 0x000000000a06a2de 6. /build/src/Functions/IFunction.cpp:645: DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x0000000012d96b0c 7. /build/src/Functions/IFunction.cpp:577: DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x0000000012d9669c 8. /build/src/Functions/IFunction.cpp:606: DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x0000000012d96edc 9. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3544: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000014033cc9 10. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3838: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000014019a9e 11. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3980: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000014018e31 12. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:4304: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000014042fa7 13. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5605: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000014013749 14. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000140127f9 15. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000014011fce 16. /build/src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000001406ce8a 17. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000014973b42 18. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000001497268d 19. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000014974d24 20. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001492924b 21. /build/src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88641 22. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 23. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 24. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 25. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 26. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 27. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 28. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 29. ? @ 0x00007fbc6213eac3 30. ? @ 0x00007fbc621d0850 2025.07.28 12:01:13.284583 [ 17611 ] {} TCPHandler: Code: 43. DB::Exception: Third argument of function throwIf must be Int8, Int16 or Int32 (passed: UInt8): In scope SELECT throwIf(number = 1000, 'Number equals 1000', 1) FROM system.numbers SETTINGS allow_custom_error_code_in_throwif = true. (ILLEGAL_TYPE_OF_ARGUMENT), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000a06a8eb 4. /build/src/Functions/throwIf.cpp:69: DB::(anonymous namespace)::FunctionThrowIf::getReturnTypeImpl(std::vector, std::allocator>> const&) const @ 0x000000000e81a20e 5. /build/src/Functions/IFunction.h:520: DB::IFunction::getReturnTypeImpl(std::vector> const&) const @ 0x000000000a06a2de 6. /build/src/Functions/IFunction.cpp:645: DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x0000000012d96b0c 7. /build/src/Functions/IFunction.cpp:577: DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x0000000012d9669c 8. /build/src/Functions/IFunction.cpp:606: DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x0000000012d96edc 9. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3544: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000014033cc9 10. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3838: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000014019a9e 11. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3980: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000014018e31 12. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:4304: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000014042fa7 13. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5605: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000014013749 14. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000140127f9 15. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000014011fce 16. /build/src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000001406ce8a 17. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000014973b42 18. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000001497268d 19. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000014974d24 20. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001492924b 21. /build/src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88641 22. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 23. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 24. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 25. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 26. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 27. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 28. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 29. ? @ 0x00007fbc6213eac3 30. ? @ 0x00007fbc621d0850 2025.07.28 12:01:13.666757 [ 7625 ] {6fe3f53c-c6b7-4b0b-935f-0ceaed4bcf60} executeQuery: Code: 42. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(equals(__table1.number, 1000_UInt16) :: 0, 'Number equals 1000'_String :: 2, _CAST(42_Int32, 'Int32'_String) :: 3) -> throwIf(equals(__table1.number, 1000_UInt16), 'Number equals 1000'_String, _CAST(42_Int32, 'Int32'_String)) UInt8 : 1'. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.6.10636.altinitytest (altinity build)) (from [::1]:43452) (comment: 00602_throw_if.sh) (query 1, line 1) (in query: SELECT throwIf(number = 1000, 'Number equals 1000', toInt32(42)) FROM system.numbers SETTINGS allow_custom_error_code_in_throwif=true), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x000000000a06b56b 4. /build/src/Functions/throwIf.cpp:153: DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000e8193b5 5. /build/src/Functions/IFunctionAdaptors.cpp:10: DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000012d995fa 6. /build/src/Functions/IFunction.cpp:353: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d93b52 7. /build/src/Functions/IFunction.cpp:420: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d95059 8. /build/src/Functions/IFunction.cpp:498: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d95c72 9. /build/src/Interpreters/ExpressionActions.cpp:636: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x00000000145176f3 10. /build/src/Processors/Transforms/ExpressionTransform.cpp:25: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x0000000016c0b34c 11. /build/src/Processors/ISimpleTransform.h:33: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000011a9a453 12. /build/src/Processors/ISimpleTransform.cpp:89: DB::ISimpleTransform::work() @ 0x000000001699fca0 13. /build/src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x00000000169bd00f 14. /build/src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x00000000169b2105 15. /build/src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeSingleThread(unsigned long) @ 0x00000000169b23be 16. /build/src/Processors/Executors/PipelineExecutor.cpp:454: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x00000000169b0be7 17. /build/src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x00000000169b03f4 18. /build/src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:se190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169bfeab 19. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc3d92 20. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fcca080 21. ? @ 0x00007fbc6213eac3 22. ? @ 0x00007fbc621d0850 2025.07.28 12:01:13.688249 [ 7625 ] {} TCPHandler: Code: 42. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(equals(__table1.number, 1000_UInt16) :: 0, 'Number equals 1000'_String :: 2, _CAST(42_Int32, 'Int32'_String) :: 3) -> throwIf(equals(__table1.number, 1000_UInt16), 'Number equals 1000'_String, _CAST(42_Int32, 'Int32'_String)) UInt8 : 1'. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x000000000a06b56b 4. /build/src/Functions/throwIf.cpp:153: DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000e8193b5 5. /build/src/Functions/IFunctionAdaptors.cpp:10: DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000012d995fa 6. /build/src/Functions/IFunction.cpp:353: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d93b52 7. /build/src/Functions/IFunction.cpp:420: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d95059 8. /build/src/Functions/IFunction.cpp:498: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d95c72 9. /build/src/Interpreters/ExpressionActions.cpp:636: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x00000000145176f3 10. /build/src/Processors/Transforms/ExpressionTransform.cpp:25: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x0000000016c0b34c 11. /build/src/Processors/ISimpleTransform.h:33: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000011a9a453 12. /build/src/Processors/ISimpleTransform.cpp:89: DB::ISimpleTransform::work() @ 0x000000001699fca0 13. /build/src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x00000000169bd00f 14. /build/src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x00000000169b2105 15. /build/src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeSingleThread(unsigned long) @ 0x00000000169b23be 16. /build/src/Processors/Executors/PipelineExecutor.cpp:454: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x00000000169b0be7 17. /build/src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x00000000169b03f4 18. /build/src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:se190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169bfeab 19. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc3d92 20. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fcca080 21. ? @ 0x00007fbc6213eac3 22. ? @ 0x00007fbc621d0850 Job's origin stack trace: 0. /build/src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000000fc33b84 1. /build/src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000000fcc2ea7 2. /build/src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fcc535c 3. /build/src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000000fcc584d 4. /build/src/Common/ThreadPool.h:279: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x00000000169bf193 5. /build/src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x00000000169bf518 6. /build/src/Server/TCPHandler.cpp:1237: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x00000000168f1525 7. /build/src/Server/TCPHandler.cpp:678: DB::TCPHandler::runImpl() @ 0x00000000168e68e5 8. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 9. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 10. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 11. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 12. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 13. ? @ 0x00007fbc6213eac3 14. ? @ 0x00007fbc621d0850 2025.07.28 12:01:13.848352 [ 3974 ] {} test_13.rmt2 (7f9b740d-015c-470e-8cc6-8ba33be0dc63): auto DB::StorageReplicatedMergeTree::processQueueEntry(ReplicatedMergeTreeQueue::SelectedEntryPtr)::(anonymous class)::operator()(LogEntryPtr &) const: Code: 86. DB::HTTPException: Received error from remote server http://146b4357c08d:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Ftest%2F01165%2Ftest_13%2Frmt%2Freplicas%2F1&part=20250728_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.6.10636.altinitytest (altinity build)) '. (RECEIVED_ERROR_FROM_REMOTE_IO_SERVER), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.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 const&, int&&, String const&, unsigned long&&, String const&) @ 0x000000000feda8d9 4. /build/src/IO/HTTPCommon.cpp:104: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x000000000feda6e2 5. /build/src/IO/HTTPCommon.cpp:93: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x000000000feda537 6. /build/src/IO/ReadWriteBufferFromHTTP.cpp:277: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x000000001184a4c4 7. /build/src/IO/ReadWriteBufferFromHTTP.cpp:285: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x000000001184a615 8. /build/src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x000000001184ae59 9. /build/src/IO/ReadWriteBufferFromHTTP.cpp:472: void std::__function::__policy_invoker::__call_impl[abi:se190107]>(std::__function::__policy_storage const*) @ 0x000000001184cedd 10. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001184858b 11. /build/src/IO/ReadWriteBufferFromHTTP.cpp:465: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x000000001184bf0b 12. /build/src/IO/ReadBuffer.h:60: DB::ReadBuffer::next() @ 0x000000000a148c7b 13. /build/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) @ 0x0000000011849fb2 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]>&)>&, 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&) @ 0x0000000011841980 15. /build/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) @ 0x000000001621208e 16. /build/src/Storages/StorageReplicatedMergeTree.cpp:5228: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl[abi:se190107] const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000015f9a5fe 17. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000015ed8bfd 18. /build/src/Storages/StorageReplicatedMergeTree.cpp:2514: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x0000000015ec9aab 19. /build/src/Storages/StorageReplicatedMergeTree.cpp:2349: DB::StorageReplicatedMergeTree::executeLogEntry(DB::ReplicatedMergeTreeLogEntry&) @ 0x0000000015eba91b 20. /build/src/Storages/StorageReplicatedMergeTree.cpp:3876: bool std::__function::__policy_invoker&)>::__call_impl[abi:se190107])::$_1, bool (std::shared_ptr&)>>(std::__function::__policy_storage const*, std::shared_ptr&) @ 0x0000000015f9837e 21. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000165d6fc3 22. /build/src/Storages/StorageReplicatedMergeTree.cpp:3872: DB::StorageReplicatedMergeTree::processQueueEntry(std::shared_ptr) @ 0x0000000015efc18a 23. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001624c1b2 24. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000162f9c70 25. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x00000000162fa55a 26. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc6653 27. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000000fccc4c3 28. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc3d92 29. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fcca080 30. ? @ 0x00007fbc6213eac3 31. ? @ 0x00007fbc621d0850 (version 25.3.6.10636.altinitytest (altinity build)) 2025.07.28 12:01:14.006103 [ 17611 ] {f33f30ed-7d42-44a2-9984-0fa59ddb501b} executeQuery: Code: 0. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(equals(__table1.number, 1000_UInt16) :: 0, 'Number equals 1000'_String :: 2, _CAST(0_Int32, 'Int32'_String) :: 3) -> throwIf(equals(__table1.number, 1000_UInt16), 'Number equals 1000'_String, _CAST(0_Int32, 'Int32'_String)) UInt8 : 1'. (OK) (version 25.3.6.10636.altinitytest (altinity build)) (from [::1]:43466) (comment: 00602_throw_if.sh) (query 1, line 1) (in query: SELECT throwIf(number = 1000, 'Number equals 1000', toInt32(0)) FROM system.numbers SETTINGS allow_custom_error_code_in_throwif=true), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x000000000a06b56b 4. /build/src/Functions/throwIf.cpp:153: DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000e8193b5 5. /build/src/Functions/IFunctionAdaptors.cpp:10: DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000012d995fa 6. /build/src/Functions/IFunction.cpp:353: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d93b52 7. /build/src/Functions/IFunction.cpp:420: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d95059 8. /build/src/Functions/IFunction.cpp:498: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d95c72 9. /build/src/Interpreters/ExpressionActions.cpp:636: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x00000000145176f3 10. /build/src/Processors/Transforms/ExpressionTransform.cpp:25: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x0000000016c0b34c 11. /build/src/Processors/ISimpleTransform.h:33: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000011a9a453 12. /build/src/Processors/ISimpleTransform.cpp:89: DB::ISimpleTransform::work() @ 0x000000001699fca0 13. /build/src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x00000000169bd00f 14. /build/src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x00000000169b2105 15. /build/src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeSingleThread(unsigned long) @ 0x00000000169b23be 16. /build/src/Processors/Executors/PipelineExecutor.cpp:454: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x00000000169b0be7 17. /build/src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x00000000169b03f4 18. /build/src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:se190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169bfeab 19. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc3d92 20. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fcca080 21. ? @ 0x00007fbc6213eac3 22. ? @ 0x00007fbc621d0850 2025.07.28 12:01:14.017099 [ 17611 ] {} TCPHandler: Code: 0. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(equals(__table1.number, 1000_UInt16) :: 0, 'Number equals 1000'_String :: 2, _CAST(0_Int32, 'Int32'_String) :: 3) -> throwIf(equals(__table1.number, 1000_UInt16), 'Number equals 1000'_String, _CAST(0_Int32, 'Int32'_String)) UInt8 : 1'. (OK), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x000000000a06b56b 4. /build/src/Functions/throwIf.cpp:153: DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000e8193b5 5. /build/src/Functions/IFunctionAdaptors.cpp:10: DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000012d995fa 6. /build/src/Functions/IFunction.cpp:353: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d93b52 7. /build/src/Functions/IFunction.cpp:420: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d95059 8. /build/src/Functions/IFunction.cpp:498: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d95c72 9. /build/src/Interpreters/ExpressionActions.cpp:636: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x00000000145176f3 10. /build/src/Processors/Transforms/ExpressionTransform.cpp:25: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x0000000016c0b34c 11. /build/src/Processors/ISimpleTransform.h:33: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000011a9a453 12. /build/src/Processors/ISimpleTransform.cpp:89: DB::ISimpleTransform::work() @ 0x000000001699fca0 13. /build/src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x00000000169bd00f 14. /build/src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x00000000169b2105 15. /build/src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeSingleThread(unsigned long) @ 0x00000000169b23be 16. /build/src/Processors/Executors/PipelineExecutor.cpp:454: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x00000000169b0be7 17. /build/src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x00000000169b03f4 18. /build/src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:se190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169bfeab 19. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc3d92 20. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fcca080 21. ? @ 0x00007fbc6213eac3 22. ? @ 0x00007fbc621d0850 Job's origin stack trace: 0. /build/src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000000fc33b84 1. /build/src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000000fcc2ea7 2. /build/src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fcc535c 3. /build/src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000000fcc584d 4. /build/src/Common/ThreadPool.h:279: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x00000000169bf193 5. /build/src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x00000000169bf518 6. /build/src/Server/TCPHandler.cpp:1237: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x00000000168f1525 7. /build/src/Server/TCPHandler.cpp:678: DB::TCPHandler::runImpl() @ 0x00000000168e68e5 8. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 9. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 10. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 11. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 12. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 13. ? @ 0x00007fbc6213eac3 14. ? @ 0x00007fbc621d0850 2025.07.28 12:01:14.189653 [ 17611 ] {0595a73d-c8b3-451c-bc89-e22f003860df} executeQuery: Code: 101. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(equals(__table1.number, 1000_UInt16) :: 0, 'Number equals 1000'_String :: 2, _CAST(101_Int32, 'Int32'_String) :: 3) -> throwIf(equals(__table1.number, 1000_UInt16), 'Number equals 1000'_String, _CAST(101_Int32, 'Int32'_String)) UInt8 : 1'. (UNEXPECTED_PACKET_FROM_CLIENT) (version 25.3.6.10636.altinitytest (altinity build)) (from [::1]:43480) (comment: 00602_throw_if.sh) (query 1, line 1) (in query: SELECT throwIf(number = 1000, 'Number equals 1000', toInt32(101)) FROM system.numbers SETTINGS allow_custom_error_code_in_throwif=true), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x000000000a06b56b 4. /build/src/Functions/throwIf.cpp:153: DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000e8193b5 5. /build/src/Functions/IFunctionAdaptors.cpp:10: DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000012d995fa 6. /build/src/Functions/IFunction.cpp:353: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d93b52 7. /build/src/Functions/IFunction.cpp:420: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d95059 8. /build/src/Functions/IFunction.cpp:498: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d95c72 9. /build/src/Interpreters/ExpressionActions.cpp:636: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x00000000145176f3 10. /build/src/Processors/Transforms/ExpressionTransform.cpp:25: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x0000000016c0b34c 11. /build/src/Processors/ISimpleTransform.h:33: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000011a9a453 12. /build/src/Processors/ISimpleTransform.cpp:89: DB::ISimpleTransform::work() @ 0x000000001699fca0 13. /build/src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x00000000169bd00f 14. /build/src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x00000000169b2105 15. /build/src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeSingleThread(unsigned long) @ 0x00000000169b23be 16. /build/src/Processors/Executors/PipelineExecutor.cpp:454: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x00000000169b0be7 17. /build/src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x00000000169b03f4 18. /build/src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:se190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169bfeab 19. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc3d92 20. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fcca080 21. ? @ 0x00007fbc6213eac3 22. ? @ 0x00007fbc621d0850 2025.07.28 12:01:14.205932 [ 17611 ] {} TCPHandler: Code: 101. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(equals(__table1.number, 1000_UInt16) :: 0, 'Number equals 1000'_String :: 2, _CAST(101_Int32, 'Int32'_String) :: 3) -> throwIf(equals(__table1.number, 1000_UInt16), 'Number equals 1000'_String, _CAST(101_Int32, 'Int32'_String)) UInt8 : 1'. (UNEXPECTED_PACKET_FROM_CLIENT), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x000000000a06b56b 4. /build/src/Functions/throwIf.cpp:153: DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000e8193b5 5. /build/src/Functions/IFunctionAdaptors.cpp:10: DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000012d995fa 6. /build/src/Functions/IFunction.cpp:353: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d93b52 7. /build/src/Functions/IFunction.cpp:420: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d95059 8. /build/src/Functions/IFunction.cpp:498: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d95c72 9. /build/src/Interpreters/ExpressionActions.cpp:636: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x00000000145176f3 10. /build/src/Processors/Transforms/ExpressionTransform.cpp:25: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x0000000016c0b34c 11. /build/src/Processors/ISimpleTransform.h:33: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000011a9a453 12. /build/src/Processors/ISimpleTransform.cpp:89: DB::ISimpleTransform::work() @ 0x000000001699fca0 13. /build/src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x00000000169bd00f 14. /build/src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x00000000169b2105 15. /build/src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeSingleThread(unsigned long) @ 0x00000000169b23be 16. /build/src/Processors/Executors/PipelineExecutor.cpp:454: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x00000000169b0be7 17. /build/src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x00000000169b03f4 18. /build/src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:se190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169bfeab 19. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc3d92 20. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fcca080 21. ? @ 0x00007fbc6213eac3 22. ? @ 0x00007fbc621d0850 Job's origin stack trace: 0. /build/src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000000fc33b84 1. /build/src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000000fcc2ea7 2. /build/src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fcc535c 3. /build/src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000000fcc584d 4. /build/src/Common/ThreadPool.h:279: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x00000000169bf193 5. /build/src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x00000000169bf518 6. /build/src/Server/TCPHandler.cpp:1237: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x00000000168f1525 7. /build/src/Server/TCPHandler.cpp:678: DB::TCPHandler::runImpl() @ 0x00000000168e68e5 8. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 9. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 10. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 11. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 12. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 13. ? @ 0x00007fbc6213eac3 14. ? @ 0x00007fbc621d0850 2025.07.28 12:01:14.540000 [ 7625 ] {6f5398d9-24ff-4862-9020-1a1388711728} executeQuery: Code: 102. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(equals(__table1.number, 1000_UInt16) :: 0, 'Number equals 1000'_String :: 2, _CAST(102_Int32, 'Int32'_String) :: 3) -> throwIf(equals(__table1.number, 1000_UInt16), 'Number equals 1000'_String, _CAST(102_Int32, 'Int32'_String)) UInt8 : 1'. (UNEXPECTED_PACKET_FROM_SERVER) (version 25.3.6.10636.altinitytest (altinity build)) (from [::1]:43492) (comment: 00602_throw_if.sh) (query 1, line 1) (in query: SELECT throwIf(number = 1000, 'Number equals 1000', toInt32(102)) FROM system.numbers SETTINGS allow_custom_error_code_in_throwif=true), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x000000000a06b56b 4. /build/src/Functions/throwIf.cpp:153: DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000e8193b5 5. /build/src/Functions/IFunctionAdaptors.cpp:10: DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000012d995fa 6. /build/src/Functions/IFunction.cpp:353: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d93b52 7. /build/src/Functions/IFunction.cpp:420: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d95059 8. /build/src/Functions/IFunction.cpp:498: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d95c72 9. /build/src/Interpreters/ExpressionActions.cpp:636: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x00000000145176f3 10. /build/src/Processors/Transforms/ExpressionTransform.cpp:25: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x0000000016c0b34c 11. /build/src/Processors/ISimpleTransform.h:33: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000011a9a453 12. /build/src/Processors/ISimpleTransform.cpp:89: DB::ISimpleTransform::work() @ 0x000000001699fca0 13. /build/src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x00000000169bd00f 14. /build/src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x00000000169b2105 15. /build/src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeSingleThread(unsigned long) @ 0x00000000169b23be 16. /build/src/Processors/Executors/PipelineExecutor.cpp:454: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x00000000169b0be7 17. /build/src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x00000000169b03f4 18. /build/src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:se190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169bfeab 19. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc3d92 20. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fcca080 21. ? @ 0x00007fbc6213eac3 22. ? @ 0x00007fbc621d0850 2025.07.28 12:01:14.570701 [ 7625 ] {} TCPHandler: Code: 102. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(equals(__table1.number, 1000_UInt16) :: 0, 'Number equals 1000'_String :: 2, _CAST(102_Int32, 'Int32'_String) :: 3) -> throwIf(equals(__table1.number, 1000_UInt16), 'Number equals 1000'_String, _CAST(102_Int32, 'Int32'_String)) UInt8 : 1'. (UNEXPECTED_PACKET_FROM_SERVER), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x000000000a06b56b 4. /build/src/Functions/throwIf.cpp:153: DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000e8193b5 5. /build/src/Functions/IFunctionAdaptors.cpp:10: DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000012d995fa 6. /build/src/Functions/IFunction.cpp:353: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d93b52 7. /build/src/Functions/IFunction.cpp:420: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d95059 8. /build/src/Functions/IFunction.cpp:498: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d95c72 9. /build/src/Interpreters/ExpressionActions.cpp:636: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x00000000145176f3 10. /build/src/Processors/Transforms/ExpressionTransform.cpp:25: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x0000000016c0b34c 11. /build/src/Processors/ISimpleTransform.h:33: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000011a9a453 12. /build/src/Processors/ISimpleTransform.cpp:89: DB::ISimpleTransform::work() @ 0x000000001699fca0 13. /build/src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x00000000169bd00f 14. /build/src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x00000000169b2105 15. /build/src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeSingleThread(unsigned long) @ 0x00000000169b23be 16. /build/src/Processors/Executors/PipelineExecutor.cpp:454: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x00000000169b0be7 17. /build/src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x00000000169b03f4 18. /build/src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:se190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169bfeab 19. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc3d92 20. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fcca080 21. ? @ 0x00007fbc6213eac3 22. ? @ 0x00007fbc621d0850 Job's origin stack trace: 0. /build/src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000000fc33b84 1. /build/src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000000fcc2ea7 2. /build/src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fcc535c 3. /build/src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000000fcc584d 4. /build/src/Common/ThreadPool.h:279: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x00000000169bf193 5. /build/src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x00000000169bf518 6. /build/src/Server/TCPHandler.cpp:1237: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x00000000168f1525 7. /build/src/Server/TCPHandler.cpp:678: DB::TCPHandler::runImpl() @ 0x00000000168e68e5 8. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 9. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 10. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 11. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 12. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 13. ? @ 0x00007fbc6213eac3 14. ? @ 0x00007fbc621d0850 2025.07.28 12:01:14.724889 [ 3971 ] {} test_13.rmt2 (7f9b740d-015c-470e-8cc6-8ba33be0dc63): auto DB::StorageReplicatedMergeTree::processQueueEntry(ReplicatedMergeTreeQueue::SelectedEntryPtr)::(anonymous class)::operator()(LogEntryPtr &) const: Code: 86. DB::HTTPException: Received error from remote server http://146b4357c08d:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Ftest%2F01165%2Ftest_13%2Frmt%2Freplicas%2F1&part=20250728_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.6.10636.altinitytest (altinity build)) '. (RECEIVED_ERROR_FROM_REMOTE_IO_SERVER), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.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 const&, int&&, String const&, unsigned long&&, String const&) @ 0x000000000feda8d9 4. /build/src/IO/HTTPCommon.cpp:104: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x000000000feda6e2 5. /build/src/IO/HTTPCommon.cpp:93: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x000000000feda537 6. /build/src/IO/ReadWriteBufferFromHTTP.cpp:277: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x000000001184a4c4 7. /build/src/IO/ReadWriteBufferFromHTTP.cpp:285: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x000000001184a615 8. /build/src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x000000001184ae59 9. /build/src/IO/ReadWriteBufferFromHTTP.cpp:472: void std::__function::__policy_invoker::__call_impl[abi:se190107]>(std::__function::__policy_storage const*) @ 0x000000001184cedd 10. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001184858b 11. /build/src/IO/ReadWriteBufferFromHTTP.cpp:465: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x000000001184bf0b 12. /build/src/IO/ReadBuffer.h:60: DB::ReadBuffer::next() @ 0x000000000a148c7b 13. /build/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) @ 0x0000000011849fb2 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]>&)>&, 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&) @ 0x0000000011841980 15. /build/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) @ 0x000000001621208e 16. /build/src/Storages/StorageReplicatedMergeTree.cpp:5228: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl[abi:se190107] const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000015f9a5fe 17. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000015ed8bfd 18. /build/src/Storages/StorageReplicatedMergeTree.cpp:2514: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x0000000015ec9aab 19. /build/src/Storages/StorageReplicatedMergeTree.cpp:2349: DB::StorageReplicatedMergeTree::executeLogEntry(DB::ReplicatedMergeTreeLogEntry&) @ 0x0000000015eba91b 20. /build/src/Storages/StorageReplicatedMergeTree.cpp:3876: bool std::__function::__policy_invoker&)>::__call_impl[abi:se190107])::$_1, bool (std::shared_ptr&)>>(std::__function::__policy_storage const*, std::shared_ptr&) @ 0x0000000015f9837e 21. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000165d6fc3 22. /build/src/Storages/StorageReplicatedMergeTree.cpp:3872: DB::StorageReplicatedMergeTree::processQueueEntry(std::shared_ptr) @ 0x0000000015efc18a 23. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001624c1b2 24. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000162f9c70 25. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x00000000162fa55a 26. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc6653 27. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000000fccc4c3 28. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc3d92 29. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fcca080 30. ? @ 0x00007fbc6213eac3 31. ? @ 0x00007fbc621d0850 (version 25.3.6.10636.altinitytest (altinity build)) 2025.07.28 12:01:14.909918 [ 7625 ] {cceeeec2-96e6-40b9-87a3-de989dae90a2} executeQuery: Code: 1001. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(equals(__table1.number, 1000_UInt16) :: 0, 'Number equals 1000'_String :: 2, _CAST(1001_Int32, 'Int32'_String) :: 3) -> throwIf(equals(__table1.number, 1000_UInt16), 'Number equals 1000'_String, _CAST(1001_Int32, 'Int32'_String)) UInt8 : 1'. (STD_EXCEPTION) (version 25.3.6.10636.altinitytest (altinity build)) (from [::1]:43494) (comment: 00602_throw_if.sh) (query 1, line 1) (in query: SELECT throwIf(number = 1000, 'Number equals 1000', toInt32(1001)) FROM system.numbers SETTINGS allow_custom_error_code_in_throwif=true), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x000000000a06b56b 4. /build/src/Functions/throwIf.cpp:153: DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000e8193b5 5. /build/src/Functions/IFunctionAdaptors.cpp:10: DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000012d995fa 6. /build/src/Functions/IFunction.cpp:353: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d93b52 7. /build/src/Functions/IFunction.cpp:420: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d95059 8. /build/src/Functions/IFunction.cpp:498: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d95c72 9. /build/src/Interpreters/ExpressionActions.cpp:636: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x00000000145176f3 10. /build/src/Processors/Transforms/ExpressionTransform.cpp:25: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x0000000016c0b34c 11. /build/src/Processors/ISimpleTransform.h:33: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000011a9a453 12. /build/src/Processors/ISimpleTransform.cpp:89: DB::ISimpleTransform::work() @ 0x000000001699fca0 13. /build/src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x00000000169bd00f 14. /build/src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x00000000169b2105 15. /build/src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeSingleThread(unsigned long) @ 0x00000000169b23be 16. /build/src/Processors/Executors/PipelineExecutor.cpp:454: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x00000000169b0be7 17. /build/src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x00000000169b03f4 18. /build/src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:se190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169bfeab 19. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc3d92 20. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fcca080 21. ? @ 0x00007fbc6213eac3 22. ? @ 0x00007fbc621d0850 2025.07.28 12:01:14.946383 [ 7625 ] {} TCPHandler: Code: 1001. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(equals(__table1.number, 1000_UInt16) :: 0, 'Number equals 1000'_String :: 2, _CAST(1001_Int32, 'Int32'_String) :: 3) -> throwIf(equals(__table1.number, 1000_UInt16), 'Number equals 1000'_String, _CAST(1001_Int32, 'Int32'_String)) UInt8 : 1'. (STD_EXCEPTION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x000000000a06b56b 4. /build/src/Functions/throwIf.cpp:153: DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000e8193b5 5. /build/src/Functions/IFunctionAdaptors.cpp:10: DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000012d995fa 6. /build/src/Functions/IFunction.cpp:353: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d93b52 7. /build/src/Functions/IFunction.cpp:420: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d95059 8. /build/src/Functions/IFunction.cpp:498: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d95c72 9. /build/src/Interpreters/ExpressionActions.cpp:636: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x00000000145176f3 10. /build/src/Processors/Transforms/ExpressionTransform.cpp:25: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x0000000016c0b34c 11. /build/src/Processors/ISimpleTransform.h:33: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000011a9a453 12. /build/src/Processors/ISimpleTransform.cpp:89: DB::ISimpleTransform::work() @ 0x000000001699fca0 13. /build/src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x00000000169bd00f 14. /build/src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x00000000169b2105 15. /build/src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeSingleThread(unsigned long) @ 0x00000000169b23be 16. /build/src/Processors/Executors/PipelineExecutor.cpp:454: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x00000000169b0be7 17. /build/src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x00000000169b03f4 18. /build/src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:se190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169bfeab 19. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc3d92 20. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fcca080 21. ? @ 0x00007fbc6213eac3 22. ? @ 0x00007fbc621d0850 Job's origin stack trace: 0. /build/src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000000fc33b84 1. /build/src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000000fcc2ea7 2. /build/src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fcc535c 3. /build/src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000000fcc584d 4. /build/src/Common/ThreadPool.h:279: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x00000000169bf193 5. /build/src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x00000000169bf518 6. /build/src/Server/TCPHandler.cpp:1237: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x00000000168f1525 7. /build/src/Server/TCPHandler.cpp:678: DB::TCPHandler::runImpl() @ 0x00000000168e68e5 8. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 9. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 10. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 11. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 12. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 13. ? @ 0x00007fbc6213eac3 14. ? @ 0x00007fbc621d0850 2025.07.28 12:01:15.144522 [ 3977 ] {} test_13.rmt2 (7f9b740d-015c-470e-8cc6-8ba33be0dc63): auto DB::StorageReplicatedMergeTree::processQueueEntry(ReplicatedMergeTreeQueue::SelectedEntryPtr)::(anonymous class)::operator()(LogEntryPtr &) const: Code: 86. DB::HTTPException: Received error from remote server http://146b4357c08d:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Ftest%2F01165%2Ftest_13%2Frmt%2Freplicas%2F1&part=20250728_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.6.10636.altinitytest (altinity build)) '. (RECEIVED_ERROR_FROM_REMOTE_IO_SERVER), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.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 const&, int&&, String const&, unsigned long&&, String const&) @ 0x000000000feda8d9 4. /build/src/IO/HTTPCommon.cpp:104: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x000000000feda6e2 5. /build/src/IO/HTTPCommon.cpp:93: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x000000000feda537 6. /build/src/IO/ReadWriteBufferFromHTTP.cpp:277: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x000000001184a4c4 7. /build/src/IO/ReadWriteBufferFromHTTP.cpp:285: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x000000001184a615 8. /build/src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x000000001184ae59 9. /build/src/IO/ReadWriteBufferFromHTTP.cpp:472: void std::__function::__policy_invoker::__call_impl[abi:se190107]>(std::__function::__policy_storage const*) @ 0x000000001184cedd 10. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001184858b 11. /build/src/IO/ReadWriteBufferFromHTTP.cpp:465: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x000000001184bf0b 12. /build/src/IO/ReadBuffer.h:60: DB::ReadBuffer::next() @ 0x000000000a148c7b 13. /build/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) @ 0x0000000011849fb2 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]>&)>&, 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&) @ 0x0000000011841980 15. /build/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) @ 0x000000001621208e 16. /build/src/Storages/StorageReplicatedMergeTree.cpp:5228: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl[abi:se190107] const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000015f9a5fe 17. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000015ed8bfd 18. /build/src/Storages/StorageReplicatedMergeTree.cpp:2514: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x0000000015ec9aab 19. /build/src/Storages/StorageReplicatedMergeTree.cpp:2349: DB::StorageReplicatedMergeTree::executeLogEntry(DB::ReplicatedMergeTreeLogEntry&) @ 0x0000000015eba91b 20. /build/src/Storages/StorageReplicatedMergeTree.cpp:3876: bool std::__function::__policy_invoker&)>::__call_impl[abi:se190107])::$_1, bool (std::shared_ptr&)>>(std::__function::__policy_storage const*, std::shared_ptr&) @ 0x0000000015f9837e 21. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000165d6fc3 22. /build/src/Storages/StorageReplicatedMergeTree.cpp:3872: DB::StorageReplicatedMergeTree::processQueueEntry(std::shared_ptr) @ 0x0000000015efc18a 23. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001624c1b2 24. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000162f9c70 25. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x00000000162fa55a 26. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc6653 27. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000000fccc4c3 28. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc3d92 29. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fcca080 30. ? @ 0x00007fbc6213eac3 31. ? @ 0x00007fbc621d0850 (version 25.3.6.10636.altinitytest (altinity build)) 2025.07.28 12:01:15.293485 [ 7625 ] {404ce463-b12b-4baf-8f94-246b079a840c} executeQuery: Code: 1002. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(equals(__table1.number, 1000_UInt16) :: 0, 'Number equals 1000'_String :: 2, _CAST(1002_Int32, 'Int32'_String) :: 3) -> throwIf(equals(__table1.number, 1000_UInt16), 'Number equals 1000'_String, _CAST(1002_Int32, 'Int32'_String)) UInt8 : 1'. (UNKNOWN_EXCEPTION) (version 25.3.6.10636.altinitytest (altinity build)) (from [::1]:43508) (comment: 00602_throw_if.sh) (query 1, line 1) (in query: SELECT throwIf(number = 1000, 'Number equals 1000', toInt32(1002)) FROM system.numbers SETTINGS allow_custom_error_code_in_throwif=true), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x000000000a06b56b 4. /build/src/Functions/throwIf.cpp:153: DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000e8193b5 5. /build/src/Functions/IFunctionAdaptors.cpp:10: DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000012d995fa 6. /build/src/Functions/IFunction.cpp:353: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d93b52 7. /build/src/Functions/IFunction.cpp:420: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d95059 8. /build/src/Functions/IFunction.cpp:498: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d95c72 9. /build/src/Interpreters/ExpressionActions.cpp:636: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x00000000145176f3 10. /build/src/Processors/Transforms/ExpressionTransform.cpp:25: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x0000000016c0b34c 11. /build/src/Processors/ISimpleTransform.h:33: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000011a9a453 12. /build/src/Processors/ISimpleTransform.cpp:89: DB::ISimpleTransform::work() @ 0x000000001699fca0 13. /build/src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x00000000169bd00f 14. /build/src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x00000000169b2105 15. /build/src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeSingleThread(unsigned long) @ 0x00000000169b23be 16. /build/src/Processors/Executors/PipelineExecutor.cpp:454: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x00000000169b0be7 17. /build/src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x00000000169b03f4 18. /build/src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:se190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169bfeab 19. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc3d92 20. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fcca080 21. ? @ 0x00007fbc6213eac3 22. ? @ 0x00007fbc621d0850 2025.07.28 12:01:15.332937 [ 3964 ] {} test_13.rmt2 (7f9b740d-015c-470e-8cc6-8ba33be0dc63): auto DB::StorageReplicatedMergeTree::processQueueEntry(ReplicatedMergeTreeQueue::SelectedEntryPtr)::(anonymous class)::operator()(LogEntryPtr &) const: Code: 86. DB::HTTPException: Received error from remote server http://146b4357c08d:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Ftest%2F01165%2Ftest_13%2Frmt%2Freplicas%2F1&part=20250728_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.6.10636.altinitytest (altinity build)) '. (RECEIVED_ERROR_FROM_REMOTE_IO_SERVER), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.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 const&, int&&, String const&, unsigned long&&, String const&) @ 0x000000000feda8d9 4. /build/src/IO/HTTPCommon.cpp:104: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x000000000feda6e2 5. /build/src/IO/HTTPCommon.cpp:93: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x000000000feda537 6. /build/src/IO/ReadWriteBufferFromHTTP.cpp:277: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x000000001184a4c4 7. /build/src/IO/ReadWriteBufferFromHTTP.cpp:285: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x000000001184a615 8. /build/src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x000000001184ae59 9. /build/src/IO/ReadWriteBufferFromHTTP.cpp:472: void std::__function::__policy_invoker::__call_impl[abi:se190107]>(std::__function::__policy_storage const*) @ 0x000000001184cedd 10. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001184858b 11. /build/src/IO/ReadWriteBufferFromHTTP.cpp:465: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x000000001184bf0b 12. /build/src/IO/ReadBuffer.h:60: DB::ReadBuffer::next() @ 0x000000000a148c7b 13. /build/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) @ 0x0000000011849fb2 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]>&)>&, 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&) @ 0x0000000011841980 15. /build/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) @ 0x000000001621208e 16. /build/src/Storages/StorageReplicatedMergeTree.cpp:5228: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl[abi:se190107] const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000015f9a5fe 17. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000015ed8bfd 18. /build/src/Storages/StorageReplicatedMergeTree.cpp:2514: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x0000000015ec9aab 19. /build/src/Storages/StorageReplicatedMergeTree.cpp:2349: DB::StorageReplicatedMergeTree::executeLogEntry(DB::ReplicatedMergeTreeLogEntry&) @ 0x0000000015eba91b 20. /build/src/Storages/StorageReplicatedMergeTree.cpp:3876: bool std::__function::__policy_invoker&)>::__call_impl[abi:se190107])::$_1, bool (std::shared_ptr&)>>(std::__function::__policy_storage const*, std::shared_ptr&) @ 0x0000000015f9837e 21. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000165d6fc3 22. /build/src/Storages/StorageReplicatedMergeTree.cpp:3872: DB::StorageReplicatedMergeTree::processQueueEntry(std::shared_ptr) @ 0x0000000015efc18a 23. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001624c1b2 24. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000162f9c70 25. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x00000000162fa55a 26. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc6653 27. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000000fccc4c3 28. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc3d92 29. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fcca080 30. ? @ 0x00007fbc6213eac3 31. ? @ 0x00007fbc621d0850 (version 25.3.6.10636.altinitytest (altinity build)) 2025.07.28 12:01:15.351644 [ 7625 ] {} TCPHandler: Code: 1002. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(equals(__table1.number, 1000_UInt16) :: 0, 'Number equals 1000'_String :: 2, _CAST(1002_Int32, 'Int32'_String) :: 3) -> throwIf(equals(__table1.number, 1000_UInt16), 'Number equals 1000'_String, _CAST(1002_Int32, 'Int32'_String)) UInt8 : 1'. (UNKNOWN_EXCEPTION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x000000000a06b56b 4. /build/src/Functions/throwIf.cpp:153: DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000e8193b5 5. /build/src/Functions/IFunctionAdaptors.cpp:10: DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000012d995fa 6. /build/src/Functions/IFunction.cpp:353: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d93b52 7. /build/src/Functions/IFunction.cpp:420: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d95059 8. /build/src/Functions/IFunction.cpp:498: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d95c72 9. /build/src/Interpreters/ExpressionActions.cpp:636: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x00000000145176f3 10. /build/src/Processors/Transforms/ExpressionTransform.cpp:25: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x0000000016c0b34c 11. /build/src/Processors/ISimpleTransform.h:33: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000011a9a453 12. /build/src/Processors/ISimpleTransform.cpp:89: DB::ISimpleTransform::work() @ 0x000000001699fca0 13. /build/src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x00000000169bd00f 14. /build/src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x00000000169b2105 15. /build/src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeSingleThread(unsigned long) @ 0x00000000169b23be 16. /build/src/Processors/Executors/PipelineExecutor.cpp:454: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x00000000169b0be7 17. /build/src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x00000000169b03f4 18. /build/src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:se190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169bfeab 19. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc3d92 20. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fcca080 21. ? @ 0x00007fbc6213eac3 22. ? @ 0x00007fbc621d0850 Job's origin stack trace: 0. /build/src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000000fc33b84 1. /build/src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000000fcc2ea7 2. /build/src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fcc535c 3. /build/src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000000fcc584d 4. /build/src/Common/ThreadPool.h:279: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x00000000169bf193 5. /build/src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x00000000169bf518 6. /build/src/Server/TCPHandler.cpp:1237: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x00000000168f1525 7. /build/src/Server/TCPHandler.cpp:678: DB::TCPHandler::runImpl() @ 0x00000000168e68e5 8. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 9. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 10. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 11. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 12. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 13. ? @ 0x00007fbc6213eac3 14. ? @ 0x00007fbc621d0850 2025.07.28 12:01:15.426001 [ 3972 ] {} test_13.rmt2 (7f9b740d-015c-470e-8cc6-8ba33be0dc63): auto DB::StorageReplicatedMergeTree::processQueueEntry(ReplicatedMergeTreeQueue::SelectedEntryPtr)::(anonymous class)::operator()(LogEntryPtr &) const: Code: 86. DB::HTTPException: Received error from remote server http://146b4357c08d:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Ftest%2F01165%2Ftest_13%2Frmt%2Freplicas%2F1&part=20250728_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.6.10636.altinitytest (altinity build)) '. (RECEIVED_ERROR_FROM_REMOTE_IO_SERVER), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.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 const&, int&&, String const&, unsigned long&&, String const&) @ 0x000000000feda8d9 4. /build/src/IO/HTTPCommon.cpp:104: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x000000000feda6e2 5. /build/src/IO/HTTPCommon.cpp:93: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x000000000feda537 6. /build/src/IO/ReadWriteBufferFromHTTP.cpp:277: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x000000001184a4c4 7. /build/src/IO/ReadWriteBufferFromHTTP.cpp:285: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x000000001184a615 8. /build/src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x000000001184ae59 9. /build/src/IO/ReadWriteBufferFromHTTP.cpp:472: void std::__function::__policy_invoker::__call_impl[abi:se190107]>(std::__function::__policy_storage const*) @ 0x000000001184cedd 10. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001184858b 11. /build/src/IO/ReadWriteBufferFromHTTP.cpp:465: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x000000001184bf0b 12. /build/src/IO/ReadBuffer.h:60: DB::ReadBuffer::next() @ 0x000000000a148c7b 13. /build/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) @ 0x0000000011849fb2 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]>&)>&, 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&) @ 0x0000000011841980 15. /build/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) @ 0x000000001621208e 16. /build/src/Storages/StorageReplicatedMergeTree.cpp:5228: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl[abi:se190107] const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000015f9a5fe 17. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000015ed8bfd 18. /build/src/Storages/StorageReplicatedMergeTree.cpp:2514: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x0000000015ec9aab 19. /build/src/Storages/StorageReplicatedMergeTree.cpp:2349: DB::StorageReplicatedMergeTree::executeLogEntry(DB::ReplicatedMergeTreeLogEntry&) @ 0x0000000015eba91b 20. /build/src/Storages/StorageReplicatedMergeTree.cpp:3876: bool std::__function::__policy_invoker&)>::__call_impl[abi:se190107])::$_1, bool (std::shared_ptr&)>>(std::__function::__policy_storage const*, std::shared_ptr&) @ 0x0000000015f9837e 21. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000165d6fc3 22. /build/src/Storages/StorageReplicatedMergeTree.cpp:3872: DB::StorageReplicatedMergeTree::processQueueEntry(std::shared_ptr) @ 0x0000000015efc18a 23. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001624c1b2 24. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000162f9c70 25. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x00000000162fa55a 26. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc6653 27. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000000fccc4c3 28. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc3d92 29. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fcca080 30. ? @ 0x00007fbc6213eac3 31. ? @ 0x00007fbc621d0850 (version 25.3.6.10636.altinitytest (altinity build)) 2025.07.28 12:01:15.780641 [ 7625 ] {10f931b6-ec25-4b0d-b80f-fe9904e2f7ab} executeQuery: Code: 999999. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(equals(__table1.number, 1000_UInt16) :: 0, 'Number equals 1000'_String :: 2, _CAST(999999_Int32, 'Int32'_String) :: 3) -> throwIf(equals(__table1.number, 1000_UInt16), 'Number equals 1000'_String, _CAST(999999_Int32, 'Int32'_String)) UInt8 : 1'. () (version 25.3.6.10636.altinitytest (altinity build)) (from [::1]:43520) (comment: 00602_throw_if.sh) (query 1, line 1) (in query: SELECT throwIf(number = 1000, 'Number equals 1000', toInt32(999999)) FROM system.numbers SETTINGS allow_custom_error_code_in_throwif=true), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x000000000a06b56b 4. /build/src/Functions/throwIf.cpp:153: DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000e8193b5 5. /build/src/Functions/IFunctionAdaptors.cpp:10: DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000012d995fa 6. /build/src/Functions/IFunction.cpp:353: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d93b52 7. /build/src/Functions/IFunction.cpp:420: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d95059 8. /build/src/Functions/IFunction.cpp:498: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d95c72 9. /build/src/Interpreters/ExpressionActions.cpp:636: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x00000000145176f3 10. /build/src/Processors/Transforms/ExpressionTransform.cpp:25: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x0000000016c0b34c 11. /build/src/Processors/ISimpleTransform.h:33: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000011a9a453 12. /build/src/Processors/ISimpleTransform.cpp:89: DB::ISimpleTransform::work() @ 0x000000001699fca0 13. /build/src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x00000000169bd00f 14. /build/src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x00000000169b2105 15. /build/src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeSingleThread(unsigned long) @ 0x00000000169b23be 16. /build/src/Processors/Executors/PipelineExecutor.cpp:454: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x00000000169b0be7 17. /build/src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x00000000169b03f4 18. /build/src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:se190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169bfeab 19. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc3d92 20. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fcca080 21. ? @ 0x00007fbc6213eac3 22. ? @ 0x00007fbc621d0850 2025.07.28 12:01:15.810948 [ 7625 ] {} TCPHandler: Code: 999999. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(equals(__table1.number, 1000_UInt16) :: 0, 'Number equals 1000'_String :: 2, _CAST(999999_Int32, 'Int32'_String) :: 3) -> throwIf(equals(__table1.number, 1000_UInt16), 'Number equals 1000'_String, _CAST(999999_Int32, 'Int32'_String)) UInt8 : 1'. (), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x000000000a06b56b 4. /build/src/Functions/throwIf.cpp:153: DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000e8193b5 5. /build/src/Functions/IFunctionAdaptors.cpp:10: DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000012d995fa 6. /build/src/Functions/IFunction.cpp:353: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d93b52 7. /build/src/Functions/IFunction.cpp:420: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d95059 8. /build/src/Functions/IFunction.cpp:498: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d95c72 9. /build/src/Interpreters/ExpressionActions.cpp:636: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x00000000145176f3 10. /build/src/Processors/Transforms/ExpressionTransform.cpp:25: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x0000000016c0b34c 11. /build/src/Processors/ISimpleTransform.h:33: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000011a9a453 12. /build/src/Processors/ISimpleTransform.cpp:89: DB::ISimpleTransform::work() @ 0x000000001699fca0 13. /build/src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x00000000169bd00f 14. /build/src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x00000000169b2105 15. /build/src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeSingleThread(unsigned long) @ 0x00000000169b23be 16. /build/src/Processors/Executors/PipelineExecutor.cpp:454: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x00000000169b0be7 17. /build/src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x00000000169b03f4 18. /build/src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:se190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169bfeab 19. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc3d92 20. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fcca080 21. ? @ 0x00007fbc6213eac3 22. ? @ 0x00007fbc621d0850 Job's origin stack trace: 0. /build/src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000000fc33b84 1. /build/src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000000fcc2ea7 2. /build/src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fcc535c 3. /build/src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000000fcc584d 4. /build/src/Common/ThreadPool.h:279: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x00000000169bf193 5. /build/src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x00000000169bf518 6. /build/src/Server/TCPHandler.cpp:1237: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x00000000168f1525 7. /build/src/Server/TCPHandler.cpp:678: DB::TCPHandler::runImpl() @ 0x00000000168e68e5 8. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 9. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 10. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 11. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 12. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 13. ? @ 0x00007fbc6213eac3 14. ? @ 0x00007fbc621d0850 2025.07.28 12:01:16.315712 [ 17611 ] {c8035eb6-4207-4ce3-b0d2-32f2ca42cda7} executeQuery: Code: -1. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(equals(__table1.number, 1000_UInt16) :: 0, 'Number equals 1000'_String :: 2, _CAST(-1_Int32, 'Int32'_String) :: 3) -> throwIf(equals(__table1.number, 1000_UInt16), 'Number equals 1000'_String, _CAST(-1_Int32, 'Int32'_String)) UInt8 : 1'. () (version 25.3.6.10636.altinitytest (altinity build)) (from [::1]:43534) (comment: 00602_throw_if.sh) (query 1, line 1) (in query: SELECT throwIf(number = 1000, 'Number equals 1000', toInt32(-1)) FROM system.numbers SETTINGS allow_custom_error_code_in_throwif=true), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x000000000a06b56b 4. /build/src/Functions/throwIf.cpp:153: DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000e8193b5 5. /build/src/Functions/IFunctionAdaptors.cpp:10: DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000012d995fa 6. /build/src/Functions/IFunction.cpp:353: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d93b52 7. /build/src/Functions/IFunction.cpp:420: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d95059 8. /build/src/Functions/IFunction.cpp:498: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d95c72 9. /build/src/Interpreters/ExpressionActions.cpp:636: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x00000000145176f3 10. /build/src/Processors/Transforms/ExpressionTransform.cpp:25: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x0000000016c0b34c 11. /build/src/Processors/ISimpleTransform.h:33: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000011a9a453 12. /build/src/Processors/ISimpleTransform.cpp:89: DB::ISimpleTransform::work() @ 0x000000001699fca0 13. /build/src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x00000000169bd00f 14. /build/src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x00000000169b2105 15. /build/src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeSingleThread(unsigned long) @ 0x00000000169b23be 16. /build/src/Processors/Executors/PipelineExecutor.cpp:454: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x00000000169b0be7 17. /build/src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x00000000169b03f4 18. /build/src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:se190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169bfeab 19. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc3d92 20. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fcca080 21. ? @ 0x00007fbc6213eac3 22. ? @ 0x00007fbc621d0850 2025.07.28 12:01:16.340180 [ 17611 ] {} TCPHandler: Code: -1. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(equals(__table1.number, 1000_UInt16) :: 0, 'Number equals 1000'_String :: 2, _CAST(-1_Int32, 'Int32'_String) :: 3) -> throwIf(equals(__table1.number, 1000_UInt16), 'Number equals 1000'_String, _CAST(-1_Int32, 'Int32'_String)) UInt8 : 1'. (), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x000000000a06b56b 4. /build/src/Functions/throwIf.cpp:153: DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000e8193b5 5. /build/src/Functions/IFunctionAdaptors.cpp:10: DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000012d995fa 6. /build/src/Functions/IFunction.cpp:353: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d93b52 7. /build/src/Functions/IFunction.cpp:420: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d95059 8. /build/src/Functions/IFunction.cpp:498: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d95c72 9. /build/src/Interpreters/ExpressionActions.cpp:636: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x00000000145176f3 10. /build/src/Processors/Transforms/ExpressionTransform.cpp:25: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x0000000016c0b34c 11. /build/src/Processors/ISimpleTransform.h:33: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000011a9a453 12. /build/src/Processors/ISimpleTransform.cpp:89: DB::ISimpleTransform::work() @ 0x000000001699fca0 13. /build/src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x00000000169bd00f 14. /build/src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x00000000169b2105 15. /build/src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeSingleThread(unsigned long) @ 0x00000000169b23be 16. /build/src/Processors/Executors/PipelineExecutor.cpp:454: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x00000000169b0be7 17. /build/src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x00000000169b03f4 18. /build/src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:se190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169bfeab 19. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc3d92 20. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fcca080 21. ? @ 0x00007fbc6213eac3 22. ? @ 0x00007fbc621d0850 Job's origin stack trace: 0. /build/src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000000fc33b84 1. /build/src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000000fcc2ea7 2. /build/src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fcc535c 3. /build/src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000000fcc584d 4. /build/src/Common/ThreadPool.h:279: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x00000000169bf193 5. /build/src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x00000000169bf518 6. /build/src/Server/TCPHandler.cpp:1237: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x00000000168f1525 7. /build/src/Server/TCPHandler.cpp:678: DB::TCPHandler::runImpl() @ 0x00000000168e68e5 8. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 9. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 10. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 11. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 12. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 13. ? @ 0x00007fbc6213eac3 14. ? @ 0x00007fbc621d0850 2025.07.28 12:01:16.632643 [ 3976 ] {} test_13.rmt2 (7f9b740d-015c-470e-8cc6-8ba33be0dc63): auto DB::StorageReplicatedMergeTree::processQueueEntry(ReplicatedMergeTreeQueue::SelectedEntryPtr)::(anonymous class)::operator()(LogEntryPtr &) const: Code: 86. DB::HTTPException: Received error from remote server http://146b4357c08d:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Ftest%2F01165%2Ftest_13%2Frmt%2Freplicas%2F1&part=20250728_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.6.10636.altinitytest (altinity build)) '. (RECEIVED_ERROR_FROM_REMOTE_IO_SERVER), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.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 const&, int&&, String const&, unsigned long&&, String const&) @ 0x000000000feda8d9 4. /build/src/IO/HTTPCommon.cpp:104: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x000000000feda6e2 5. /build/src/IO/HTTPCommon.cpp:93: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x000000000feda537 6. /build/src/IO/ReadWriteBufferFromHTTP.cpp:277: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x000000001184a4c4 7. /build/src/IO/ReadWriteBufferFromHTTP.cpp:285: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x000000001184a615 8. /build/src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x000000001184ae59 9. /build/src/IO/ReadWriteBufferFromHTTP.cpp:472: void std::__function::__policy_invoker::__call_impl[abi:se190107]>(std::__function::__policy_storage const*) @ 0x000000001184cedd 10. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001184858b 11. /build/src/IO/ReadWriteBufferFromHTTP.cpp:465: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x000000001184bf0b 12. /build/src/IO/ReadBuffer.h:60: DB::ReadBuffer::next() @ 0x000000000a148c7b 13. /build/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) @ 0x0000000011849fb2 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]>&)>&, 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&) @ 0x0000000011841980 15. /build/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) @ 0x000000001621208e 16. /build/src/Storages/StorageReplicatedMergeTree.cpp:5228: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl[abi:se190107] const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000015f9a5fe 17. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000015ed8bfd 18. /build/src/Storages/StorageReplicatedMergeTree.cpp:2514: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x0000000015ec9aab 19. /build/src/Storages/StorageReplicatedMergeTree.cpp:2349: DB::StorageReplicatedMergeTree::executeLogEntry(DB::ReplicatedMergeTreeLogEntry&) @ 0x0000000015eba91b 20. /build/src/Storages/StorageReplicatedMergeTree.cpp:3876: bool std::__function::__policy_invoker&)>::__call_impl[abi:se190107])::$_1, bool (std::shared_ptr&)>>(std::__function::__policy_storage const*, std::shared_ptr&) @ 0x0000000015f9837e 21. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000165d6fc3 22. /build/src/Storages/StorageReplicatedMergeTree.cpp:3872: DB::StorageReplicatedMergeTree::processQueueEntry(std::shared_ptr) @ 0x0000000015efc18a 23. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001624c1b2 24. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000162f9c70 25. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x00000000162fa55a 26. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc6653 27. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000000fccc4c3 28. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc3d92 29. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fcca080 30. ? @ 0x00007fbc6213eac3 31. ? @ 0x00007fbc621d0850 (version 25.3.6.10636.altinitytest (altinity build)) 2025.07.28 12:01:17.244539 [ 3963 ] {} test_13.rmt2 (7f9b740d-015c-470e-8cc6-8ba33be0dc63): auto DB::StorageReplicatedMergeTree::processQueueEntry(ReplicatedMergeTreeQueue::SelectedEntryPtr)::(anonymous class)::operator()(LogEntryPtr &) const: Code: 86. DB::HTTPException: Received error from remote server http://146b4357c08d:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Ftest%2F01165%2Ftest_13%2Frmt%2Freplicas%2F1&part=20250728_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.6.10636.altinitytest (altinity build)) '. (RECEIVED_ERROR_FROM_REMOTE_IO_SERVER), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.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 const&, int&&, String const&, unsigned long&&, String const&) @ 0x000000000feda8d9 4. /build/src/IO/HTTPCommon.cpp:104: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x000000000feda6e2 5. /build/src/IO/HTTPCommon.cpp:93: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x000000000feda537 6. /build/src/IO/ReadWriteBufferFromHTTP.cpp:277: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x000000001184a4c4 7. /build/src/IO/ReadWriteBufferFromHTTP.cpp:285: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x000000001184a615 8. /build/src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x000000001184ae59 9. /build/src/IO/ReadWriteBufferFromHTTP.cpp:472: void std::__function::__policy_invoker::__call_impl[abi:se190107]>(std::__function::__policy_storage const*) @ 0x000000001184cedd 10. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001184858b 11. /build/src/IO/ReadWriteBufferFromHTTP.cpp:465: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x000000001184bf0b 12. /build/src/IO/ReadBuffer.h:60: DB::ReadBuffer::next() @ 0x000000000a148c7b 13. /build/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) @ 0x0000000011849fb2 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]>&)>&, 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&) @ 0x0000000011841980 15. /build/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) @ 0x000000001621208e 16. /build/src/Storages/StorageReplicatedMergeTree.cpp:5228: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl[abi:se190107] const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000015f9a5fe 17. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000015ed8bfd 18. /build/src/Storages/StorageReplicatedMergeTree.cpp:2514: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x0000000015ec9aab 19. /build/src/Storages/StorageReplicatedMergeTree.cpp:2349: DB::StorageReplicatedMergeTree::executeLogEntry(DB::ReplicatedMergeTreeLogEntry&) @ 0x0000000015eba91b 20. /build/src/Storages/StorageReplicatedMergeTree.cpp:3876: bool std::__function::__policy_invoker&)>::__call_impl[abi:se190107])::$_1, bool (std::shared_ptr&)>>(std::__function::__policy_storage const*, std::shared_ptr&) @ 0x0000000015f9837e 21. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000165d6fc3 22. /build/src/Storages/StorageReplicatedMergeTree.cpp:3872: DB::StorageReplicatedMergeTree::processQueueEntry(std::shared_ptr) @ 0x0000000015efc18a 23. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001624c1b2 24. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000162f9c70 25. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x00000000162fa55a 26. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc6653 27. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000000fccc4c3 28. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc3d92 29. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fcca080 30. ? @ 0x00007fbc6213eac3 31. ? @ 0x00007fbc621d0850 (version 25.3.6.10636.altinitytest (altinity build)) 2025.07.28 12:01:17.760827 [ 3964 ] {} test_13.rmt2 (7f9b740d-015c-470e-8cc6-8ba33be0dc63): auto DB::StorageReplicatedMergeTree::processQueueEntry(ReplicatedMergeTreeQueue::SelectedEntryPtr)::(anonymous class)::operator()(LogEntryPtr &) const: Code: 86. DB::HTTPException: Received error from remote server http://146b4357c08d:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Ftest%2F01165%2Ftest_13%2Frmt%2Freplicas%2F1&part=20250728_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.6.10636.altinitytest (altinity build)) '. (RECEIVED_ERROR_FROM_REMOTE_IO_SERVER), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.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 const&, int&&, String const&, unsigned long&&, String const&) @ 0x000000000feda8d9 4. /build/src/IO/HTTPCommon.cpp:104: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x000000000feda6e2 5. /build/src/IO/HTTPCommon.cpp:93: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x000000000feda537 6. /build/src/IO/ReadWriteBufferFromHTTP.cpp:277: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x000000001184a4c4 7. /build/src/IO/ReadWriteBufferFromHTTP.cpp:285: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x000000001184a615 8. /build/src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x000000001184ae59 9. /build/src/IO/ReadWriteBufferFromHTTP.cpp:472: void std::__function::__policy_invoker::__call_impl[abi:se190107]>(std::__function::__policy_storage const*) @ 0x000000001184cedd 10. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001184858b 11. /build/src/IO/ReadWriteBufferFromHTTP.cpp:465: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x000000001184bf0b 12. /build/src/IO/ReadBuffer.h:60: DB::ReadBuffer::next() @ 0x000000000a148c7b 13. /build/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) @ 0x0000000011849fb2 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]>&)>&, 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&) @ 0x0000000011841980 15. /build/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) @ 0x000000001621208e 16. /build/src/Storages/StorageReplicatedMergeTree.cpp:5228: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl[abi:se190107] const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000015f9a5fe 17. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000015ed8bfd 18. /build/src/Storages/StorageReplicatedMergeTree.cpp:2514: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x0000000015ec9aab 19. /build/src/Storages/StorageReplicatedMergeTree.cpp:2349: DB::StorageReplicatedMergeTree::executeLogEntry(DB::ReplicatedMergeTreeLogEntry&) @ 0x0000000015eba91b 20. /build/src/Storages/StorageReplicatedMergeTree.cpp:3876: bool std::__function::__policy_invoker&)>::__call_impl[abi:se190107])::$_1, bool (std::shared_ptr&)>>(std::__function::__policy_storage const*, std::shared_ptr&) @ 0x0000000015f9837e 21. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000165d6fc3 22. /build/src/Storages/StorageReplicatedMergeTree.cpp:3872: DB::StorageReplicatedMergeTree::processQueueEntry(std::shared_ptr) @ 0x0000000015efc18a 23. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001624c1b2 24. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000162f9c70 25. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x00000000162fa55a 26. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc6653 27. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000000fccc4c3 28. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc3d92 29. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fcca080 30. ? @ 0x00007fbc6213eac3 31. ? @ 0x00007fbc621d0850 (version 25.3.6.10636.altinitytest (altinity build)) 2025.07.28 12:01:18.813855 [ 3967 ] {} test_13.rmt2 (7f9b740d-015c-470e-8cc6-8ba33be0dc63): auto DB::StorageReplicatedMergeTree::processQueueEntry(ReplicatedMergeTreeQueue::SelectedEntryPtr)::(anonymous class)::operator()(LogEntryPtr &) const: Code: 86. DB::HTTPException: Received error from remote server http://146b4357c08d:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Ftest%2F01165%2Ftest_13%2Frmt%2Freplicas%2F1&part=20250728_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.6.10636.altinitytest (altinity build)) '. (RECEIVED_ERROR_FROM_REMOTE_IO_SERVER), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.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 const&, int&&, String const&, unsigned long&&, String const&) @ 0x000000000feda8d9 4. /build/src/IO/HTTPCommon.cpp:104: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x000000000feda6e2 5. /build/src/IO/HTTPCommon.cpp:93: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x000000000feda537 6. /build/src/IO/ReadWriteBufferFromHTTP.cpp:277: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x000000001184a4c4 7. /build/src/IO/ReadWriteBufferFromHTTP.cpp:285: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x000000001184a615 8. /build/src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x000000001184ae59 9. /build/src/IO/ReadWriteBufferFromHTTP.cpp:472: void std::__function::__policy_invoker::__call_impl[abi:se190107]>(std::__function::__policy_storage const*) @ 0x000000001184cedd 10. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001184858b 11. /build/src/IO/ReadWriteBufferFromHTTP.cpp:465: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x000000001184bf0b 12. /build/src/IO/ReadBuffer.h:60: DB::ReadBuffer::next() @ 0x000000000a148c7b 13. /build/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) @ 0x0000000011849fb2 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]>&)>&, 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&) @ 0x0000000011841980 15. /build/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) @ 0x000000001621208e 16. /build/src/Storages/StorageReplicatedMergeTree.cpp:5228: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl[abi:se190107] const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000015f9a5fe 17. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000015ed8bfd 18. /build/src/Storages/StorageReplicatedMergeTree.cpp:2514: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x0000000015ec9aab 19. /build/src/Storages/StorageReplicatedMergeTree.cpp:2349: DB::StorageReplicatedMergeTree::executeLogEntry(DB::ReplicatedMergeTreeLogEntry&) @ 0x0000000015eba91b 20. /build/src/Storages/StorageReplicatedMergeTree.cpp:3876: bool std::__function::__policy_invoker&)>::__call_impl[abi:se190107])::$_1, bool (std::shared_ptr&)>>(std::__function::__policy_storage const*, std::shared_ptr&) @ 0x0000000015f9837e 21. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000165d6fc3 22. /build/src/Storages/StorageReplicatedMergeTree.cpp:3872: DB::StorageReplicatedMergeTree::processQueueEntry(std::shared_ptr) @ 0x0000000015efc18a 23. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001624c1b2 24. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000162f9c70 25. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x00000000162fa55a 26. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc6653 27. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000000fccc4c3 28. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc3d92 29. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fcca080 30. ? @ 0x00007fbc6213eac3 31. ? @ 0x00007fbc621d0850 (version 25.3.6.10636.altinitytest (altinity build)) 2025.07.28 12:01:19.060232 [ 3961 ] {} test_13.rmt2 (7f9b740d-015c-470e-8cc6-8ba33be0dc63): auto DB::StorageReplicatedMergeTree::processQueueEntry(ReplicatedMergeTreeQueue::SelectedEntryPtr)::(anonymous class)::operator()(LogEntryPtr &) const: Code: 86. DB::HTTPException: Received error from remote server http://146b4357c08d:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Ftest%2F01165%2Ftest_13%2Frmt%2Freplicas%2F1&part=20250728_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.6.10636.altinitytest (altinity build)) '. (RECEIVED_ERROR_FROM_REMOTE_IO_SERVER), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.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 const&, int&&, String const&, unsigned long&&, String const&) @ 0x000000000feda8d9 4. /build/src/IO/HTTPCommon.cpp:104: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x000000000feda6e2 5. /build/src/IO/HTTPCommon.cpp:93: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x000000000feda537 6. /build/src/IO/ReadWriteBufferFromHTTP.cpp:277: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x000000001184a4c4 7. /build/src/IO/ReadWriteBufferFromHTTP.cpp:285: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x000000001184a615 8. /build/src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x000000001184ae59 9. /build/src/IO/ReadWriteBufferFromHTTP.cpp:472: void std::__function::__policy_invoker::__call_impl[abi:se190107]>(std::__function::__policy_storage const*) @ 0x000000001184cedd 10. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001184858b 11. /build/src/IO/ReadWriteBufferFromHTTP.cpp:465: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x000000001184bf0b 12. /build/src/IO/ReadBuffer.h:60: DB::ReadBuffer::next() @ 0x000000000a148c7b 13. /build/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) @ 0x0000000011849fb2 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]>&)>&, 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&) @ 0x0000000011841980 15. /build/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) @ 0x000000001621208e 16. /build/src/Storages/StorageReplicatedMergeTree.cpp:5228: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl[abi:se190107] const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000015f9a5fe 17. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000015ed8bfd 18. /build/src/Storages/StorageReplicatedMergeTree.cpp:2514: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x0000000015ec9aab 19. /build/src/Storages/StorageReplicatedMergeTree.cpp:2349: DB::StorageReplicatedMergeTree::executeLogEntry(DB::ReplicatedMergeTreeLogEntry&) @ 0x0000000015eba91b 20. /build/src/Storages/StorageReplicatedMergeTree.cpp:3876: bool std::__function::__policy_invoker&)>::__call_impl[abi:se190107])::$_1, bool (std::shared_ptr&)>>(std::__function::__policy_storage const*, std::shared_ptr&) @ 0x0000000015f9837e 21. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000165d6fc3 22. /build/src/Storages/StorageReplicatedMergeTree.cpp:3872: DB::StorageReplicatedMergeTree::processQueueEntry(std::shared_ptr) @ 0x0000000015efc18a 23. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001624c1b2 24. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000162f9c70 25. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x00000000162fa55a 26. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc6653 27. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000000fccc4c3 28. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc3d92 29. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fcca080 30. ? @ 0x00007fbc6213eac3 31. ? @ 0x00007fbc621d0850 (version 25.3.6.10636.altinitytest (altinity build)) 2025.07.28 12:01:19.561034 [ 7625 ] {760c1b4d-18fc-48b6-af2c-395037d6e5d4} executeQuery: Code: 69. DB::Exception: Too large offset: -9223372036854775808 in function neighbor. (ARGUMENT_OUT_OF_BOUND) (version 25.3.6.10636.altinitytest (altinity build)) (from [::1]:43628) (comment: 01353_neighbor_overflow.sql) (query 2, line 2) (in query: SELECT neighbor(toString(number), -9223372036854775808) FROM numbers(100);), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, long&, String&&) @ 0x000000000db1ef6b 4. /build/src/Functions/neighbor.cpp:143: DB::(anonymous namespace)::FunctionNeighbor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000db1e44e 5. /build/src/Functions/IFunction.h:437: DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000a069f2a 6. /build/src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000012d9965a 7. /build/src/Functions/IFunction.cpp:351: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d93b02 8. /build/src/Functions/IFunction.cpp:424: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d94e1b 9. /build/src/Functions/IFunction.cpp:498: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d95c72 10. /build/src/Interpreters/ActionsDAG.cpp:812: DB::ActionsDAG::evaluatePartialResult(std::unordered_map, std::equal_to, std::allocator>>&, std::vector> const&, unsigned long, bool) @ 0x0000000013fa38cc 11. /build/src/Interpreters/ActionsDAG.cpp:892: DB::ActionsDAG::updateHeader(DB::Block const&) const @ 0x0000000013fa29a8 12. /build/src/Processors/Transforms/ExpressionTransform.cpp:10: DB::ExpressionTransform::transformHeader(DB::Block const&, DB::ActionsDAG const&) @ 0x0000000016c0afd2 13. /build/src/Processors/QueryPlan/ExpressionStep.cpp:38: DB::ExpressionStep::ExpressionStep(DB::Block const&, DB::ActionsDAG) @ 0x0000000016db8ad1 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107](DB::Block const&, DB::ActionsDAG&&) @ 0x00000000131ee01a 15. /build/src/Planner/Planner.cpp:392: DB::(anonymous namespace)::addExpressionStep(DB::QueryPlan&, std::shared_ptr&, String const&, std::unordered_set, std::hash>, std::equal_to>, std::allocator>>&) @ 0x000000001498191d 16. /build/src/Planner/Planner.cpp:1648: DB::Planner::buildPlanForQueryNode() @ 0x000000001497b7aa 17. /build/src/Planner/Planner.cpp:1308: DB::Planner::buildQueryPlanIfNeeded() @ 0x000000001497685c 18. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:255: DB::InterpreterSelectQueryAnalyzer::getQueryPlan() @ 0x000000001497476d 19. /build/src/Interpreters/executeQuery.cpp:1405: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88806 20. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 21. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 22. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 23. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 24. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 25. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 26. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 27. ? @ 0x00007fbc6213eac3 28. ? @ 0x00007fbc621d0850 2025.07.28 12:01:19.580617 [ 7625 ] {} TCPHandler: Code: 69. DB::Exception: Too large offset: -9223372036854775808 in function neighbor. (ARGUMENT_OUT_OF_BOUND), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, long&, String&&) @ 0x000000000db1ef6b 4. /build/src/Functions/neighbor.cpp:143: DB::(anonymous namespace)::FunctionNeighbor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000db1e44e 5. /build/src/Functions/IFunction.h:437: DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000a069f2a 6. /build/src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000012d9965a 7. /build/src/Functions/IFunction.cpp:351: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d93b02 8. /build/src/Functions/IFunction.cpp:424: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d94e1b 9. /build/src/Functions/IFunction.cpp:498: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d95c72 10. /build/src/Interpreters/ActionsDAG.cpp:812: DB::ActionsDAG::evaluatePartialResult(std::unordered_map, std::equal_to, std::allocator>>&, std::vector> const&, unsigned long, bool) @ 0x0000000013fa38cc 11. /build/src/Interpreters/ActionsDAG.cpp:892: DB::ActionsDAG::updateHeader(DB::Block const&) const @ 0x0000000013fa29a8 12. /build/src/Processors/Transforms/ExpressionTransform.cpp:10: DB::ExpressionTransform::transformHeader(DB::Block const&, DB::ActionsDAG const&) @ 0x0000000016c0afd2 13. /build/src/Processors/QueryPlan/ExpressionStep.cpp:38: DB::ExpressionStep::ExpressionStep(DB::Block const&, DB::ActionsDAG) @ 0x0000000016db8ad1 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107](DB::Block const&, DB::ActionsDAG&&) @ 0x00000000131ee01a 15. /build/src/Planner/Planner.cpp:392: DB::(anonymous namespace)::addExpressionStep(DB::QueryPlan&, std::shared_ptr&, String const&, std::unordered_set, std::hash>, std::equal_to>, std::allocator>>&) @ 0x000000001498191d 16. /build/src/Planner/Planner.cpp:1648: DB::Planner::buildPlanForQueryNode() @ 0x000000001497b7aa 17. /build/src/Planner/Planner.cpp:1308: DB::Planner::buildQueryPlanIfNeeded() @ 0x000000001497685c 18. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:255: DB::InterpreterSelectQueryAnalyzer::getQueryPlan() @ 0x000000001497476d 19. /build/src/Interpreters/executeQuery.cpp:1405: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88806 20. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 21. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 22. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 23. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 24. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 25. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 26. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 27. ? @ 0x00007fbc6213eac3 28. ? @ 0x00007fbc621d0850 2025.07.28 12:01:19.804926 [ 7625 ] {8e723a1b-b17f-4a5e-a870-7d3f12dd0d3c} executeQuery: Code: 69. DB::Exception: Too large offset: -8798814316622667796 in function neighbor: while executing 'FUNCTION neighbor(toString(__table1.number) :: 3, toInt64(rand64()) :: 0) -> neighbor(toString(__table1.number), toInt64(rand64())) String : 1'. (ARGUMENT_OUT_OF_BOUND) (version 25.3.6.10636.altinitytest (altinity build)) (from [::1]:43628) (comment: 01353_neighbor_overflow.sql) (query 3, line 3) (in query: WITH neighbor(toString(number), toInt64(rand64())) AS x SELECT * FROM system.numbers WHERE NOT ignore(x);), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, long&, String&&) @ 0x000000000db1ef6b 4. /build/src/Functions/neighbor.cpp:203: DB::(anonymous namespace)::FunctionNeighbor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000db1e36c 5. /build/src/Functions/IFunctionAdaptors.cpp:10: DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000012d995fa 6. /build/src/Functions/IFunction.cpp:353: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d93b52 7. /build/src/Functions/IFunction.cpp:424: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d94e1b 8. /build/src/Functions/IFunction.cpp:498: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d95c72 9. /build/src/Interpreters/ExpressionActions.cpp:636: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x00000000145176f3 10. /build/src/Processors/Transforms/FilterTransform.cpp:142: DB::FilterTransform::doTransform(DB::Chunk&) @ 0x0000000016c0f114 11. /build/src/Processors/Transforms/FilterTransform.cpp:126: DB::FilterTransform::transform(DB::Chunk&) @ 0x0000000016c0f034 12. /build/src/Processors/ISimpleTransform.h:33: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000011a9a453 13. /build/src/Processors/ISimpleTransform.cpp:89: DB::ISimpleTransform::work() @ 0x000000001699fca0 14. /build/src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x00000000169bd00f 15. /build/src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x00000000169b2105 16. /build/src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeSingleThread(unsigned long) @ 0x00000000169b23be 17. /build/src/Processors/Executors/PipelineExecutor.cpp:454: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x00000000169b0be7 18. /build/src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x00000000169b03f4 19. /build/src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:se190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169bfeab 20. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc3d92 21. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fcca080 22. ? @ 0x00007fbc6213eac3 23. ? @ 0x00007fbc621d0850 2025.07.28 12:01:19.819043 [ 7625 ] {} TCPHandler: Code: 69. DB::Exception: Too large offset: -8798814316622667796 in function neighbor: while executing 'FUNCTION neighbor(toString(__table1.number) :: 3, toInt64(rand64()) :: 0) -> neighbor(toString(__table1.number), toInt64(rand64())) String : 1'. (ARGUMENT_OUT_OF_BOUND), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, long&, String&&) @ 0x000000000db1ef6b 4. /build/src/Functions/neighbor.cpp:203: DB::(anonymous namespace)::FunctionNeighbor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000db1e36c 5. /build/src/Functions/IFunctionAdaptors.cpp:10: DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000012d995fa 6. /build/src/Functions/IFunction.cpp:353: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d93b52 7. /build/src/Functions/IFunction.cpp:424: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d94e1b 8. /build/src/Functions/IFunction.cpp:498: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d95c72 9. /build/src/Interpreters/ExpressionActions.cpp:636: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x00000000145176f3 10. /build/src/Processors/Transforms/FilterTransform.cpp:142: DB::FilterTransform::doTransform(DB::Chunk&) @ 0x0000000016c0f114 11. /build/src/Processors/Transforms/FilterTransform.cpp:126: DB::FilterTransform::transform(DB::Chunk&) @ 0x0000000016c0f034 12. /build/src/Processors/ISimpleTransform.h:33: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000011a9a453 13. /build/src/Processors/ISimpleTransform.cpp:89: DB::ISimpleTransform::work() @ 0x000000001699fca0 14. /build/src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x00000000169bd00f 15. /build/src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x00000000169b2105 16. /build/src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeSingleThread(unsigned long) @ 0x00000000169b23be 17. /build/src/Processors/Executors/PipelineExecutor.cpp:454: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x00000000169b0be7 18. /build/src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x00000000169b03f4 19. /build/src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:se190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169bfeab 20. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc3d92 21. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fcca080 22. ? @ 0x00007fbc6213eac3 23. ? @ 0x00007fbc621d0850 Job's origin stack trace: 0. /build/src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000000fc33b84 1. /build/src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000000fcc2ea7 2. /build/src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fcc535c 3. /build/src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000000fcc584d 4. /build/src/Common/ThreadPool.h:279: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x00000000169bf193 5. /build/src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x00000000169bf518 6. /build/src/Server/TCPHandler.cpp:1237: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x00000000168f1525 7. /build/src/Server/TCPHandler.cpp:678: DB::TCPHandler::runImpl() @ 0x00000000168e68e5 8. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 9. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 10. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 11. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 12. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 13. ? @ 0x00007fbc6213eac3 14. ? @ 0x00007fbc621d0850 2025.07.28 12:01:19.899937 [ 3974 ] {} test_13.rmt2 (7f9b740d-015c-470e-8cc6-8ba33be0dc63): auto DB::StorageReplicatedMergeTree::processQueueEntry(ReplicatedMergeTreeQueue::SelectedEntryPtr)::(anonymous class)::operator()(LogEntryPtr &) const: Code: 86. DB::HTTPException: Received error from remote server http://146b4357c08d:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Ftest%2F01165%2Ftest_13%2Frmt%2Freplicas%2F1&part=20250728_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.6.10636.altinitytest (altinity build)) '. (RECEIVED_ERROR_FROM_REMOTE_IO_SERVER), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.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 const&, int&&, String const&, unsigned long&&, String const&) @ 0x000000000feda8d9 4. /build/src/IO/HTTPCommon.cpp:104: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x000000000feda6e2 5. /build/src/IO/HTTPCommon.cpp:93: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x000000000feda537 6. /build/src/IO/ReadWriteBufferFromHTTP.cpp:277: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x000000001184a4c4 7. /build/src/IO/ReadWriteBufferFromHTTP.cpp:285: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x000000001184a615 8. /build/src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x000000001184ae59 9. /build/src/IO/ReadWriteBufferFromHTTP.cpp:472: void std::__function::__policy_invoker::__call_impl[abi:se190107]>(std::__function::__policy_storage const*) @ 0x000000001184cedd 10. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001184858b 11. /build/src/IO/ReadWriteBufferFromHTTP.cpp:465: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x000000001184bf0b 12. /build/src/IO/ReadBuffer.h:60: DB::ReadBuffer::next() @ 0x000000000a148c7b 13. /build/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) @ 0x0000000011849fb2 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]>&)>&, 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&) @ 0x0000000011841980 15. /build/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) @ 0x000000001621208e 16. /build/src/Storages/StorageReplicatedMergeTree.cpp:5228: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl[abi:se190107] const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000015f9a5fe 17. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000015ed8bfd 18. /build/src/Storages/StorageReplicatedMergeTree.cpp:2514: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x0000000015ec9aab 19. /build/src/Storages/StorageReplicatedMergeTree.cpp:2349: DB::StorageReplicatedMergeTree::executeLogEntry(DB::ReplicatedMergeTreeLogEntry&) @ 0x0000000015eba91b 20. /build/src/Storages/StorageReplicatedMergeTree.cpp:3876: bool std::__function::__policy_invoker&)>::__call_impl[abi:se190107])::$_1, bool (std::shared_ptr&)>>(std::__function::__policy_storage const*, std::shared_ptr&) @ 0x0000000015f9837e 21. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000165d6fc3 22. /build/src/Storages/StorageReplicatedMergeTree.cpp:3872: DB::StorageReplicatedMergeTree::processQueueEntry(std::shared_ptr) @ 0x0000000015efc18a 23. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001624c1b2 24. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000162f9c70 25. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x00000000162fa55a 26. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc6653 27. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000000fccc4c3 28. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc3d92 29. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fcca080 30. ? @ 0x00007fbc6213eac3 31. ? @ 0x00007fbc621d0850 (version 25.3.6.10636.altinitytest (altinity build)) 2025.07.28 12:01:20.089935 [ 3960 ] {} test_13.rmt2 (7f9b740d-015c-470e-8cc6-8ba33be0dc63): auto DB::StorageReplicatedMergeTree::processQueueEntry(ReplicatedMergeTreeQueue::SelectedEntryPtr)::(anonymous class)::operator()(LogEntryPtr &) const: Code: 86. DB::HTTPException: Received error from remote server http://146b4357c08d:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Ftest%2F01165%2Ftest_13%2Frmt%2Freplicas%2F1&part=20250728_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.6.10636.altinitytest (altinity build)) '. (RECEIVED_ERROR_FROM_REMOTE_IO_SERVER), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.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 const&, int&&, String const&, unsigned long&&, String const&) @ 0x000000000feda8d9 4. /build/src/IO/HTTPCommon.cpp:104: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x000000000feda6e2 5. /build/src/IO/HTTPCommon.cpp:93: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x000000000feda537 6. /build/src/IO/ReadWriteBufferFromHTTP.cpp:277: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x000000001184a4c4 7. /build/src/IO/ReadWriteBufferFromHTTP.cpp:285: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x000000001184a615 8. /build/src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x000000001184ae59 9. /build/src/IO/ReadWriteBufferFromHTTP.cpp:472: void std::__function::__policy_invoker::__call_impl[abi:se190107]>(std::__function::__policy_storage const*) @ 0x000000001184cedd 10. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001184858b 11. /build/src/IO/ReadWriteBufferFromHTTP.cpp:465: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x000000001184bf0b 12. /build/src/IO/ReadBuffer.h:60: DB::ReadBuffer::next() @ 0x000000000a148c7b 13. /build/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) @ 0x0000000011849fb2 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]>&)>&, 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&) @ 0x0000000011841980 15. /build/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) @ 0x000000001621208e 16. /build/src/Storages/StorageReplicatedMergeTree.cpp:5228: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl[abi:se190107] const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000015f9a5fe 17. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000015ed8bfd 18. /build/src/Storages/StorageReplicatedMergeTree.cpp:2514: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x0000000015ec9aab 19. /build/src/Storages/StorageReplicatedMergeTree.cpp:2349: DB::StorageReplicatedMergeTree::executeLogEntry(DB::ReplicatedMergeTreeLogEntry&) @ 0x0000000015eba91b 20. /build/src/Storages/StorageReplicatedMergeTree.cpp:3876: bool std::__function::__policy_invoker&)>::__call_impl[abi:se190107])::$_1, bool (std::shared_ptr&)>>(std::__function::__policy_storage const*, std::shared_ptr&) @ 0x0000000015f9837e 21. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000165d6fc3 22. /build/src/Storages/StorageReplicatedMergeTree.cpp:3872: DB::StorageReplicatedMergeTree::processQueueEntry(std::shared_ptr) @ 0x0000000015efc18a 23. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001624c1b2 24. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000162f9c70 25. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x00000000162fa55a 26. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc6653 27. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000000fccc4c3 28. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc3d92 29. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fcca080 30. ? @ 0x00007fbc6213eac3 31. ? @ 0x00007fbc621d0850 (version 25.3.6.10636.altinitytest (altinity build)) 2025.07.28 12:01:20.252298 [ 3977 ] {} test_13.rmt2 (7f9b740d-015c-470e-8cc6-8ba33be0dc63): auto DB::StorageReplicatedMergeTree::processQueueEntry(ReplicatedMergeTreeQueue::SelectedEntryPtr)::(anonymous class)::operator()(LogEntryPtr &) const: Code: 86. DB::HTTPException: Received error from remote server http://146b4357c08d:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Ftest%2F01165%2Ftest_13%2Frmt%2Freplicas%2F1&part=20250728_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.6.10636.altinitytest (altinity build)) '. (RECEIVED_ERROR_FROM_REMOTE_IO_SERVER), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.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 const&, int&&, String const&, unsigned long&&, String const&) @ 0x000000000feda8d9 4. /build/src/IO/HTTPCommon.cpp:104: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x000000000feda6e2 5. /build/src/IO/HTTPCommon.cpp:93: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x000000000feda537 6. /build/src/IO/ReadWriteBufferFromHTTP.cpp:277: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x000000001184a4c4 7. /build/src/IO/ReadWriteBufferFromHTTP.cpp:285: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x000000001184a615 8. /build/src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x000000001184ae59 9. /build/src/IO/ReadWriteBufferFromHTTP.cpp:472: void std::__function::__policy_invoker::__call_impl[abi:se190107]>(std::__function::__policy_storage const*) @ 0x000000001184cedd 10. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001184858b 11. /build/src/IO/ReadWriteBufferFromHTTP.cpp:465: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x000000001184bf0b 12. /build/src/IO/ReadBuffer.h:60: DB::ReadBuffer::next() @ 0x000000000a148c7b 13. /build/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) @ 0x0000000011849fb2 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]>&)>&, 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&) @ 0x0000000011841980 15. /build/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) @ 0x000000001621208e 16. /build/src/Storages/StorageReplicatedMergeTree.cpp:5228: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl[abi:se190107] const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000015f9a5fe 17. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000015ed8bfd 18. /build/src/Storages/StorageReplicatedMergeTree.cpp:2514: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x0000000015ec9aab 19. /build/src/Storages/StorageReplicatedMergeTree.cpp:2349: DB::StorageReplicatedMergeTree::executeLogEntry(DB::ReplicatedMergeTreeLogEntry&) @ 0x0000000015eba91b 20. /build/src/Storages/StorageReplicatedMergeTree.cpp:3876: bool std::__function::__policy_invoker&)>::__call_impl[abi:se190107])::$_1, bool (std::shared_ptr&)>>(std::__function::__policy_storage const*, std::shared_ptr&) @ 0x0000000015f9837e 21. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000165d6fc3 22. /build/src/Storages/StorageReplicatedMergeTree.cpp:3872: DB::StorageReplicatedMergeTree::processQueueEntry(std::shared_ptr) @ 0x0000000015efc18a 23. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001624c1b2 24. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000162f9c70 25. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x00000000162fa55a 26. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc6653 27. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000000fccc4c3 28. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc3d92 29. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fcca080 30. ? @ 0x00007fbc6213eac3 31. ? @ 0x00007fbc621d0850 (version 25.3.6.10636.altinitytest (altinity build)) 2025.07.28 12:01:20.406680 [ 3970 ] {} test_13.rmt2 (7f9b740d-015c-470e-8cc6-8ba33be0dc63): auto DB::StorageReplicatedMergeTree::processQueueEntry(ReplicatedMergeTreeQueue::SelectedEntryPtr)::(anonymous class)::operator()(LogEntryPtr &) const: Code: 86. DB::HTTPException: Received error from remote server http://146b4357c08d:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Ftest%2F01165%2Ftest_13%2Frmt%2Freplicas%2F1&part=20250728_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.6.10636.altinitytest (altinity build)) '. (RECEIVED_ERROR_FROM_REMOTE_IO_SERVER), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.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 const&, int&&, String const&, unsigned long&&, String const&) @ 0x000000000feda8d9 4. /build/src/IO/HTTPCommon.cpp:104: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x000000000feda6e2 5. /build/src/IO/HTTPCommon.cpp:93: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x000000000feda537 6. /build/src/IO/ReadWriteBufferFromHTTP.cpp:277: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x000000001184a4c4 7. /build/src/IO/ReadWriteBufferFromHTTP.cpp:285: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x000000001184a615 8. /build/src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x000000001184ae59 9. /build/src/IO/ReadWriteBufferFromHTTP.cpp:472: void std::__function::__policy_invoker::__call_impl[abi:se190107]>(std::__function::__policy_storage const*) @ 0x000000001184cedd 10. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001184858b 11. /build/src/IO/ReadWriteBufferFromHTTP.cpp:465: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x000000001184bf0b 12. /build/src/IO/ReadBuffer.h:60: DB::ReadBuffer::next() @ 0x000000000a148c7b 13. /build/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) @ 0x0000000011849fb2 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]>&)>&, 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&) @ 0x0000000011841980 15. /build/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) @ 0x000000001621208e 16. /build/src/Storages/StorageReplicatedMergeTree.cpp:5228: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl[abi:se190107] const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000015f9a5fe 17. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000015ed8bfd 18. /build/src/Storages/StorageReplicatedMergeTree.cpp:2514: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x0000000015ec9aab 19. /build/src/Storages/StorageReplicatedMergeTree.cpp:2349: DB::StorageReplicatedMergeTree::executeLogEntry(DB::ReplicatedMergeTreeLogEntry&) @ 0x0000000015eba91b 20. /build/src/Storages/StorageReplicatedMergeTree.cpp:3876: bool std::__function::__policy_invoker&)>::__call_impl[abi:se190107])::$_1, bool (std::shared_ptr&)>>(std::__function::__policy_storage const*, std::shared_ptr&) @ 0x0000000015f9837e 21. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000165d6fc3 22. /build/src/Storages/StorageReplicatedMergeTree.cpp:3872: DB::StorageReplicatedMergeTree::processQueueEntry(std::shared_ptr) @ 0x0000000015efc18a 23. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001624c1b2 24. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000162f9c70 25. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x00000000162fa55a 26. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc6653 27. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000000fccc4c3 28. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc3d92 29. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fcca080 30. ? @ 0x00007fbc6213eac3 31. ? @ 0x00007fbc621d0850 (version 25.3.6.10636.altinitytest (altinity build)) 2025.07.28 12:01:21.132683 [ 3961 ] {} test_13.rmt2 (7f9b740d-015c-470e-8cc6-8ba33be0dc63): auto DB::StorageReplicatedMergeTree::processQueueEntry(ReplicatedMergeTreeQueue::SelectedEntryPtr)::(anonymous class)::operator()(LogEntryPtr &) const: Code: 86. DB::HTTPException: Received error from remote server http://146b4357c08d:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Ftest%2F01165%2Ftest_13%2Frmt%2Freplicas%2F1&part=20250728_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.6.10636.altinitytest (altinity build)) '. (RECEIVED_ERROR_FROM_REMOTE_IO_SERVER), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.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 const&, int&&, String const&, unsigned long&&, String const&) @ 0x000000000feda8d9 4. /build/src/IO/HTTPCommon.cpp:104: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x000000000feda6e2 5. /build/src/IO/HTTPCommon.cpp:93: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x000000000feda537 6. /build/src/IO/ReadWriteBufferFromHTTP.cpp:277: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x000000001184a4c4 7. /build/src/IO/ReadWriteBufferFromHTTP.cpp:285: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x000000001184a615 8. /build/src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x000000001184ae59 9. /build/src/IO/ReadWriteBufferFromHTTP.cpp:472: void std::__function::__policy_invoker::__call_impl[abi:se190107]>(std::__function::__policy_storage const*) @ 0x000000001184cedd 10. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001184858b 11. /build/src/IO/ReadWriteBufferFromHTTP.cpp:465: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x000000001184bf0b 12. /build/src/IO/ReadBuffer.h:60: DB::ReadBuffer::next() @ 0x000000000a148c7b 13. /build/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) @ 0x0000000011849fb2 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]>&)>&, 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&) @ 0x0000000011841980 15. /build/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) @ 0x000000001621208e 16. /build/src/Storages/StorageReplicatedMergeTree.cpp:5228: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl[abi:se190107] const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000015f9a5fe 17. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000015ed8bfd 18. /build/src/Storages/StorageReplicatedMergeTree.cpp:2514: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x0000000015ec9aab 19. /build/src/Storages/StorageReplicatedMergeTree.cpp:2349: DB::StorageReplicatedMergeTree::executeLogEntry(DB::ReplicatedMergeTreeLogEntry&) @ 0x0000000015eba91b 20. /build/src/Storages/StorageReplicatedMergeTree.cpp:3876: bool std::__function::__policy_invoker&)>::__call_impl[abi:se190107])::$_1, bool (std::shared_ptr&)>>(std::__function::__policy_storage const*, std::shared_ptr&) @ 0x0000000015f9837e 21. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000165d6fc3 22. /build/src/Storages/StorageReplicatedMergeTree.cpp:3872: DB::StorageReplicatedMergeTree::processQueueEntry(std::shared_ptr) @ 0x0000000015efc18a 23. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001624c1b2 24. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000162f9c70 25. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x00000000162fa55a 26. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc6653 27. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000000fccc4c3 28. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc3d92 29. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fcca080 30. ? @ 0x00007fbc6213eac3 31. ? @ 0x00007fbc621d0850 (version 25.3.6.10636.altinitytest (altinity build)) 2025.07.28 12:01:21.315037 [ 3969 ] {} test_13.rmt2 (7f9b740d-015c-470e-8cc6-8ba33be0dc63): auto DB::StorageReplicatedMergeTree::processQueueEntry(ReplicatedMergeTreeQueue::SelectedEntryPtr)::(anonymous class)::operator()(LogEntryPtr &) const: Code: 86. DB::HTTPException: Received error from remote server http://146b4357c08d:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Ftest%2F01165%2Ftest_13%2Frmt%2Freplicas%2F1&part=20250728_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.6.10636.altinitytest (altinity build)) '. (RECEIVED_ERROR_FROM_REMOTE_IO_SERVER), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.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 const&, int&&, String const&, unsigned long&&, String const&) @ 0x000000000feda8d9 4. /build/src/IO/HTTPCommon.cpp:104: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x000000000feda6e2 5. /build/src/IO/HTTPCommon.cpp:93: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x000000000feda537 6. /build/src/IO/ReadWriteBufferFromHTTP.cpp:277: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x000000001184a4c4 7. /build/src/IO/ReadWriteBufferFromHTTP.cpp:285: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x000000001184a615 8. /build/src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x000000001184ae59 9. /build/src/IO/ReadWriteBufferFromHTTP.cpp:472: void std::__function::__policy_invoker::__call_impl[abi:se190107]>(std::__function::__policy_storage const*) @ 0x000000001184cedd 10. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001184858b 11. /build/src/IO/ReadWriteBufferFromHTTP.cpp:465: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x000000001184bf0b 12. /build/src/IO/ReadBuffer.h:60: DB::ReadBuffer::next() @ 0x000000000a148c7b 13. /build/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) @ 0x0000000011849fb2 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]>&)>&, 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&) @ 0x0000000011841980 15. /build/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) @ 0x000000001621208e 16. /build/src/Storages/StorageReplicatedMergeTree.cpp:5228: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl[abi:se190107] const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000015f9a5fe 17. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000015ed8bfd 18. /build/src/Storages/StorageReplicatedMergeTree.cpp:2514: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x0000000015ec9aab 19. /build/src/Storages/StorageReplicatedMergeTree.cpp:2349: DB::StorageReplicatedMergeTree::executeLogEntry(DB::ReplicatedMergeTreeLogEntry&) @ 0x0000000015eba91b 20. /build/src/Storages/StorageReplicatedMergeTree.cpp:3876: bool std::__function::__policy_invoker&)>::__call_impl[abi:se190107])::$_1, bool (std::shared_ptr&)>>(std::__function::__policy_storage const*, std::shared_ptr&) @ 0x0000000015f9837e 21. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000165d6fc3 22. /build/src/Storages/StorageReplicatedMergeTree.cpp:3872: DB::StorageReplicatedMergeTree::processQueueEntry(std::shared_ptr) @ 0x0000000015efc18a 23. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001624c1b2 24. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000162f9c70 25. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x00000000162fa55a 26. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc6653 27. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000000fccc4c3 28. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc3d92 29. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fcca080 30. ? @ 0x00007fbc6213eac3 31. ? @ 0x00007fbc621d0850 (version 25.3.6.10636.altinitytest (altinity build)) 2025.07.28 12:01:21.774720 [ 3966 ] {} test_13.rmt2 (7f9b740d-015c-470e-8cc6-8ba33be0dc63): auto DB::StorageReplicatedMergeTree::processQueueEntry(ReplicatedMergeTreeQueue::SelectedEntryPtr)::(anonymous class)::operator()(LogEntryPtr &) const: Code: 86. DB::HTTPException: Received error from remote server http://146b4357c08d:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Ftest%2F01165%2Ftest_13%2Frmt%2Freplicas%2F1&part=20250728_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.6.10636.altinitytest (altinity build)) '. (RECEIVED_ERROR_FROM_REMOTE_IO_SERVER), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.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 const&, int&&, String const&, unsigned long&&, String const&) @ 0x000000000feda8d9 4. /build/src/IO/HTTPCommon.cpp:104: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x000000000feda6e2 5. /build/src/IO/HTTPCommon.cpp:93: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x000000000feda537 6. /build/src/IO/ReadWriteBufferFromHTTP.cpp:277: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x000000001184a4c4 7. /build/src/IO/ReadWriteBufferFromHTTP.cpp:285: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x000000001184a615 8. /build/src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x000000001184ae59 9. /build/src/IO/ReadWriteBufferFromHTTP.cpp:472: void std::__function::__policy_invoker::__call_impl[abi:se190107]>(std::__function::__policy_storage const*) @ 0x000000001184cedd 10. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001184858b 11. /build/src/IO/ReadWriteBufferFromHTTP.cpp:465: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x000000001184bf0b 12. /build/src/IO/ReadBuffer.h:60: DB::ReadBuffer::next() @ 0x000000000a148c7b 13. /build/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) @ 0x0000000011849fb2 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]>&)>&, 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&) @ 0x0000000011841980 15. /build/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) @ 0x000000001621208e 16. /build/src/Storages/StorageReplicatedMergeTree.cpp:5228: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl[abi:se190107] const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000015f9a5fe 17. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000015ed8bfd 18. /build/src/Storages/StorageReplicatedMergeTree.cpp:2514: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x0000000015ec9aab 19. /build/src/Storages/StorageReplicatedMergeTree.cpp:2349: DB::StorageReplicatedMergeTree::executeLogEntry(DB::ReplicatedMergeTreeLogEntry&) @ 0x0000000015eba91b 20. /build/src/Storages/StorageReplicatedMergeTree.cpp:3876: bool std::__function::__policy_invoker&)>::__call_impl[abi:se190107])::$_1, bool (std::shared_ptr&)>>(std::__function::__policy_storage const*, std::shared_ptr&) @ 0x0000000015f9837e 21. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000165d6fc3 22. /build/src/Storages/StorageReplicatedMergeTree.cpp:3872: DB::StorageReplicatedMergeTree::processQueueEntry(std::shared_ptr) @ 0x0000000015efc18a 23. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001624c1b2 24. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000162f9c70 25. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x00000000162fa55a 26. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc6653 27. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000000fccc4c3 28. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc3d92 29. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fcca080 30. ? @ 0x00007fbc6213eac3 31. ? @ 0x00007fbc621d0850 (version 25.3.6.10636.altinitytest (altinity build)) 2025.07.28 12:01:22.344207 [ 3971 ] {} test_13.rmt2 (7f9b740d-015c-470e-8cc6-8ba33be0dc63): auto DB::StorageReplicatedMergeTree::processQueueEntry(ReplicatedMergeTreeQueue::SelectedEntryPtr)::(anonymous class)::operator()(LogEntryPtr &) const: Code: 86. DB::HTTPException: Received error from remote server http://146b4357c08d:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Ftest%2F01165%2Ftest_13%2Frmt%2Freplicas%2F1&part=20250728_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.6.10636.altinitytest (altinity build)) '. (RECEIVED_ERROR_FROM_REMOTE_IO_SERVER), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.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 const&, int&&, String const&, unsigned long&&, String const&) @ 0x000000000feda8d9 4. /build/src/IO/HTTPCommon.cpp:104: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x000000000feda6e2 5. /build/src/IO/HTTPCommon.cpp:93: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x000000000feda537 6. /build/src/IO/ReadWriteBufferFromHTTP.cpp:277: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x000000001184a4c4 7. /build/src/IO/ReadWriteBufferFromHTTP.cpp:285: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x000000001184a615 8. /build/src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x000000001184ae59 9. /build/src/IO/ReadWriteBufferFromHTTP.cpp:472: void std::__function::__policy_invoker::__call_impl[abi:se190107]>(std::__function::__policy_storage const*) @ 0x000000001184cedd 10. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001184858b 11. /build/src/IO/ReadWriteBufferFromHTTP.cpp:465: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x000000001184bf0b 12. /build/src/IO/ReadBuffer.h:60: DB::ReadBuffer::next() @ 0x000000000a148c7b 13. /build/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) @ 0x0000000011849fb2 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]>&)>&, 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&) @ 0x0000000011841980 15. /build/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) @ 0x000000001621208e 16. /build/src/Storages/StorageReplicatedMergeTree.cpp:5228: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl[abi:se190107] const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000015f9a5fe 17. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000015ed8bfd 18. /build/src/Storages/StorageReplicatedMergeTree.cpp:2514: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x0000000015ec9aab 19. /build/src/Storages/StorageReplicatedMergeTree.cpp:2349: DB::StorageReplicatedMergeTree::executeLogEntry(DB::ReplicatedMergeTreeLogEntry&) @ 0x0000000015eba91b 20. /build/src/Storages/StorageReplicatedMergeTree.cpp:3876: bool std::__function::__policy_invoker&)>::__call_impl[abi:se190107])::$_1, bool (std::shared_ptr&)>>(std::__function::__policy_storage const*, std::shared_ptr&) @ 0x0000000015f9837e 21. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000165d6fc3 22. /build/src/Storages/StorageReplicatedMergeTree.cpp:3872: DB::StorageReplicatedMergeTree::processQueueEntry(std::shared_ptr) @ 0x0000000015efc18a 23. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001624c1b2 24. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000162f9c70 25. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x00000000162fa55a 26. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc6653 27. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000000fccc4c3 28. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc3d92 29. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fcca080 30. ? @ 0x00007fbc6213eac3 31. ? @ 0x00007fbc621d0850 (version 25.3.6.10636.altinitytest (altinity build)) 2025.07.28 12:01:22.351004 [ 11826 ] {0b4b59b0-f25b-470e-a413-b9bac9520857} executeQuery: Code: 57. DB::Exception: Table test_15.t1 already exists. (TABLE_ALREADY_EXISTS) (version 25.3.6.10636.altinitytest (altinity build)) (from [::1]:34704) (comment: 03274_squashing_transform_sparse_bug.sql) (query 9, line 13) (in query: CREATE TABLE t1 (`x` UInt64, `y` Tuple(UInt64, UInt64)) ENGINE = MergeTree ORDER BY x SETTINGS index_granularity = 29375, min_bytes_for_wide_part = 0, ratio_of_defaults_for_sparse_serialization = 1., replace_long_file_name_to_hash = true, max_file_name_length = 98, min_bytes_for_full_part_storage = 444519431, compact_parts_max_bytes_to_buffer = 326582789, compact_parts_max_granules_to_buffer = 256, compact_parts_merge_max_bytes_to_prefetch_part = 28271148, merge_max_block_size = 14946, old_parts_lifetime = 453., prefer_fetch_merged_part_size_threshold = 1, vertical_merge_algorithm_min_rows_to_activate = 1000000, vertical_merge_algorithm_min_columns_to_activate = 1, min_merge_bytes_to_use_direct_io = 3492881029, index_granularity_bytes = 24253265, 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 = true, enable_block_offset_column = false, cache_populated_by_fetch = true, marks_compress_block_size = 91818, primary_key_compress_block_size = 61181, 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. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000a06a8eb 4. /build/src/Interpreters/InterpreterCreateQuery.cpp:1824: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x0000000014901d53 5. /build/src/Interpreters/InterpreterCreateQuery.cpp:1743: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000148f9aa9 6. /build/src/Interpreters/InterpreterCreateQuery.cpp:2352: DB::InterpreterCreateQuery::execute() @ 0x0000000014905a41 7. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88dc9 8. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 9. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 10. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 11. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 12. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 13. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 14. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 15. ? @ 0x00007fbc6213eac3 16. ? @ 0x00007fbc621d0850 2025.07.28 12:01:22.397358 [ 11826 ] {} TCPHandler: Code: 57. DB::Exception: Table test_15.t1 already exists. (TABLE_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000a06a8eb 4. /build/src/Interpreters/InterpreterCreateQuery.cpp:1824: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x0000000014901d53 5. /build/src/Interpreters/InterpreterCreateQuery.cpp:1743: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000148f9aa9 6. /build/src/Interpreters/InterpreterCreateQuery.cpp:2352: DB::InterpreterCreateQuery::execute() @ 0x0000000014905a41 7. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88dc9 8. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 9. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 10. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 11. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 12. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 13. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 14. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 15. ? @ 0x00007fbc6213eac3 16. ? @ 0x00007fbc621d0850 2025.07.28 12:01:22.481382 [ 3967 ] {} test_13.rmt2 (7f9b740d-015c-470e-8cc6-8ba33be0dc63): auto DB::StorageReplicatedMergeTree::processQueueEntry(ReplicatedMergeTreeQueue::SelectedEntryPtr)::(anonymous class)::operator()(LogEntryPtr &) const: Code: 86. DB::HTTPException: Received error from remote server http://146b4357c08d:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Ftest%2F01165%2Ftest_13%2Frmt%2Freplicas%2F1&part=20250728_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.6.10636.altinitytest (altinity build)) '. (RECEIVED_ERROR_FROM_REMOTE_IO_SERVER), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.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 const&, int&&, String const&, unsigned long&&, String const&) @ 0x000000000feda8d9 4. /build/src/IO/HTTPCommon.cpp:104: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x000000000feda6e2 5. /build/src/IO/HTTPCommon.cpp:93: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x000000000feda537 6. /build/src/IO/ReadWriteBufferFromHTTP.cpp:277: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x000000001184a4c4 7. /build/src/IO/ReadWriteBufferFromHTTP.cpp:285: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x000000001184a615 8. /build/src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x000000001184ae59 9. /build/src/IO/ReadWriteBufferFromHTTP.cpp:472: void std::__function::__policy_invoker::__call_impl[abi:se190107]>(std::__function::__policy_storage const*) @ 0x000000001184cedd 10. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001184858b 11. /build/src/IO/ReadWriteBufferFromHTTP.cpp:465: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x000000001184bf0b 12. /build/src/IO/ReadBuffer.h:60: DB::ReadBuffer::next() @ 0x000000000a148c7b 13. /build/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) @ 0x0000000011849fb2 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]>&)>&, 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&) @ 0x0000000011841980 15. /build/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) @ 0x000000001621208e 16. /build/src/Storages/StorageReplicatedMergeTree.cpp:5228: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl[abi:se190107] const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000015f9a5fe 17. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000015ed8bfd 18. /build/src/Storages/StorageReplicatedMergeTree.cpp:2514: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x0000000015ec9aab 19. /build/src/Storages/StorageReplicatedMergeTree.cpp:2349: DB::StorageReplicatedMergeTree::executeLogEntry(DB::ReplicatedMergeTreeLogEntry&) @ 0x0000000015eba91b 20. /build/src/Storages/StorageReplicatedMergeTree.cpp:3876: bool std::__function::__policy_invoker&)>::__call_impl[abi:se190107])::$_1, bool (std::shared_ptr&)>>(std::__function::__policy_storage const*, std::shared_ptr&) @ 0x0000000015f9837e 21. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000165d6fc3 22. /build/src/Storages/StorageReplicatedMergeTree.cpp:3872: DB::StorageReplicatedMergeTree::processQueueEntry(std::shared_ptr) @ 0x0000000015efc18a 23. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001624c1b2 24. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000162f9c70 25. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x00000000162fa55a 26. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc6653 27. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000000fccc4c3 28. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc3d92 29. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fcca080 30. ? @ 0x00007fbc6213eac3 31. ? @ 0x00007fbc621d0850 (version 25.3.6.10636.altinitytest (altinity build)) 2025.07.28 12:01:23.290519 [ 3962 ] {} test_13.rmt2 (7f9b740d-015c-470e-8cc6-8ba33be0dc63): auto DB::StorageReplicatedMergeTree::processQueueEntry(ReplicatedMergeTreeQueue::SelectedEntryPtr)::(anonymous class)::operator()(LogEntryPtr &) const: Code: 86. DB::HTTPException: Received error from remote server http://146b4357c08d:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Ftest%2F01165%2Ftest_13%2Frmt%2Freplicas%2F1&part=20250728_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.6.10636.altinitytest (altinity build)) '. (RECEIVED_ERROR_FROM_REMOTE_IO_SERVER), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.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 const&, int&&, String const&, unsigned long&&, String const&) @ 0x000000000feda8d9 4. /build/src/IO/HTTPCommon.cpp:104: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x000000000feda6e2 5. /build/src/IO/HTTPCommon.cpp:93: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x000000000feda537 6. /build/src/IO/ReadWriteBufferFromHTTP.cpp:277: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x000000001184a4c4 7. /build/src/IO/ReadWriteBufferFromHTTP.cpp:285: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x000000001184a615 8. /build/src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x000000001184ae59 9. /build/src/IO/ReadWriteBufferFromHTTP.cpp:472: void std::__function::__policy_invoker::__call_impl[abi:se190107]>(std::__function::__policy_storage const*) @ 0x000000001184cedd 10. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001184858b 11. /build/src/IO/ReadWriteBufferFromHTTP.cpp:465: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x000000001184bf0b 12. /build/src/IO/ReadBuffer.h:60: DB::ReadBuffer::next() @ 0x000000000a148c7b 13. /build/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) @ 0x0000000011849fb2 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]>&)>&, 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&) @ 0x0000000011841980 15. /build/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) @ 0x000000001621208e 16. /build/src/Storages/StorageReplicatedMergeTree.cpp:5228: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl[abi:se190107] const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000015f9a5fe 17. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000015ed8bfd 18. /build/src/Storages/StorageReplicatedMergeTree.cpp:2514: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x0000000015ec9aab 19. /build/src/Storages/StorageReplicatedMergeTree.cpp:2349: DB::StorageReplicatedMergeTree::executeLogEntry(DB::ReplicatedMergeTreeLogEntry&) @ 0x0000000015eba91b 20. /build/src/Storages/StorageReplicatedMergeTree.cpp:3876: bool std::__function::__policy_invoker&)>::__call_impl[abi:se190107])::$_1, bool (std::shared_ptr&)>>(std::__function::__policy_storage const*, std::shared_ptr&) @ 0x0000000015f9837e 21. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000165d6fc3 22. /build/src/Storages/StorageReplicatedMergeTree.cpp:3872: DB::StorageReplicatedMergeTree::processQueueEntry(std::shared_ptr) @ 0x0000000015efc18a 23. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001624c1b2 24. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000162f9c70 25. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x00000000162fa55a 26. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc6653 27. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000000fccc4c3 28. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc3d92 29. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fcca080 30. ? @ 0x00007fbc6213eac3 31. ? @ 0x00007fbc621d0850 (version 25.3.6.10636.altinitytest (altinity build)) 2025.07.28 12:01:23.368227 [ 5879 ] {} 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. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000000a074fcb 4. /build/src/Server/HTTPHandler.cpp:244: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000001686e00b 5. /build/src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x0000000016870807 6. /build/src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x0000000016907e99 7. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 8. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 9. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 10. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 11. ? @ 0x00007fbc6213eac3 12. ? @ 0x00007fbc621d0850 (version 25.3.6.10636.altinitytest (altinity build)) 2025.07.28 12:01:23.556428 [ 17252 ] {c3dda27b-3f16-447d-a38f-62dc8fe77f5e} executeQuery: Code: 70. DB::Exception: Value in column Int8 cannot be safely converted into type UInt8: In scope SELECT accurateCast(-1, 'UInt8'). (CANNOT_CONVERT_TYPE) (version 25.3.6.10636.altinitytest (altinity build)) (from [::1]:39342) (comment: 01601_accurate_cast.sql) (query 1, line 1) (in query: SELECT accurateCast(-1, 'UInt8');), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000a06a8eb 4. /build/src/Functions/FunctionsConversion.h:1861: 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) @ 0x0000000012e05fd3 5. /build/src/Functions/FunctionsConversion.h:3582: 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 @ 0x0000000012e0140f 6. /build/src/Core/callOnTypeIndex.h:259: 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 @ 0x0000000012e00bb9 7. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: COW::immutable_ptr std::__function::__policy_invoker::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)>::__call_impl[abi:se190107]::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) @ 0x0000000012e00a4c 8. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000012ddcb1b 9. /build/src/Functions/IFunction.h:57: DB::IExecutableFunction::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000a08134a 10. /build/src/Functions/IFunction.cpp:351: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d93b02 11. /build/src/Functions/IFunction.cpp:177: DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d93698 12. /build/src/Functions/IFunction.cpp:343: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d93aad 13. /build/src/Functions/IFunction.cpp:424: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d94e1b 14. /build/src/Functions/IFunction.cpp:498: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d95c72 15. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3567: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000014034494 16. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3838: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000014019a9e 17. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3980: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000014018e31 18. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:4304: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000014042fa7 19. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5605: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000014013749 20. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000140127f9 21. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000014011fce 22. /build/src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000001406ce8a 23. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000014973b42 24. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000001497268d 25. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000014974d24 26. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001492924b 27. /build/src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88641 28. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 29. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 30. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 31. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 2025.07.28 12:01:23.568546 [ 17252 ] {} TCPHandler: Code: 70. DB::Exception: Value in column Int8 cannot be safely converted into type UInt8: In scope SELECT accurateCast(-1, 'UInt8'). (CANNOT_CONVERT_TYPE), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000a06a8eb 4. /build/src/Functions/FunctionsConversion.h:1861: 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) @ 0x0000000012e05fd3 5. /build/src/Functions/FunctionsConversion.h:3582: 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 @ 0x0000000012e0140f 6. /build/src/Core/callOnTypeIndex.h:259: 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 @ 0x0000000012e00bb9 7. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: COW::immutable_ptr std::__function::__policy_invoker::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)>::__call_impl[abi:se190107]::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) @ 0x0000000012e00a4c 8. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000012ddcb1b 9. /build/src/Functions/IFunction.h:57: DB::IExecutableFunction::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000a08134a 10. /build/src/Functions/IFunction.cpp:351: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d93b02 11. /build/src/Functions/IFunction.cpp:177: DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d93698 12. /build/src/Functions/IFunction.cpp:343: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d93aad 13. /build/src/Functions/IFunction.cpp:424: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d94e1b 14. /build/src/Functions/IFunction.cpp:498: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d95c72 15. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3567: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000014034494 16. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3838: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000014019a9e 17. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3980: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000014018e31 18. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:4304: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000014042fa7 19. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5605: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000014013749 20. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000140127f9 21. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000014011fce 22. /build/src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000001406ce8a 23. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000014973b42 24. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000001497268d 25. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000014974d24 26. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001492924b 27. /build/src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88641 28. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 29. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 30. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 31. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 2025.07.28 12:01:23.724156 [ 7625 ] {} 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. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception>&, String>(int, FormatStringHelperImpl>&>::type, std::type_identity::type>, std::basic_string_view>&, String&&) @ 0x000000001385a5eb 4. /build/src/Access/SettingsConstraints.cpp:376: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000013859b18 5. /build/src/Access/SettingsConstraints.cpp:300: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000013858faf 6. /build/src/Access/SettingsConstraints.cpp:209: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000013859223 7. /build/src/Interpreters/Context.cpp:2690: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000014436134 8. /build/src/Interpreters/Context.cpp:2729: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x000000001443662b 9. /build/src/Server/HTTPHandler.cpp:457: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000001686d165 10. /build/src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x0000000016870807 11. /build/src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x0000000016907e99 12. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 13. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 14. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 15. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 16. ? @ 0x00007fbc6213eac3 17. ? @ 0x00007fbc621d0850 (version 25.3.6.10636.altinitytest (altinity build)) 2025.07.28 12:01:23.788176 [ 3965 ] {} test_13.rmt2 (7f9b740d-015c-470e-8cc6-8ba33be0dc63): auto DB::StorageReplicatedMergeTree::processQueueEntry(ReplicatedMergeTreeQueue::SelectedEntryPtr)::(anonymous class)::operator()(LogEntryPtr &) const: Code: 86. DB::HTTPException: Received error from remote server http://146b4357c08d:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Ftest%2F01165%2Ftest_13%2Frmt%2Freplicas%2F1&part=20250728_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.6.10636.altinitytest (altinity build)) '. (RECEIVED_ERROR_FROM_REMOTE_IO_SERVER), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.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 const&, int&&, String const&, unsigned long&&, String const&) @ 0x000000000feda8d9 4. /build/src/IO/HTTPCommon.cpp:104: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x000000000feda6e2 5. /build/src/IO/HTTPCommon.cpp:93: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x000000000feda537 6. /build/src/IO/ReadWriteBufferFromHTTP.cpp:277: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x000000001184a4c4 7. /build/src/IO/ReadWriteBufferFromHTTP.cpp:285: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x000000001184a615 8. /build/src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x000000001184ae59 9. /build/src/IO/ReadWriteBufferFromHTTP.cpp:472: void std::__function::__policy_invoker::__call_impl[abi:se190107]>(std::__function::__policy_storage const*) @ 0x000000001184cedd 10. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001184858b 11. /build/src/IO/ReadWriteBufferFromHTTP.cpp:465: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x000000001184bf0b 12. /build/src/IO/ReadBuffer.h:60: DB::ReadBuffer::next() @ 0x000000000a148c7b 13. /build/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) @ 0x0000000011849fb2 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]>&)>&, 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&) @ 0x0000000011841980 15. /build/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) @ 0x000000001621208e 16. /build/src/Storages/StorageReplicatedMergeTree.cpp:5228: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl[abi:se190107] const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000015f9a5fe 17. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000015ed8bfd 18. /build/src/Storages/StorageReplicatedMergeTree.cpp:2514: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x0000000015ec9aab 19. /build/src/Storages/StorageReplicatedMergeTree.cpp:2349: DB::StorageReplicatedMergeTree::executeLogEntry(DB::ReplicatedMergeTreeLogEntry&) @ 0x0000000015eba91b 20. /build/src/Storages/StorageReplicatedMergeTree.cpp:3876: bool std::__function::__policy_invoker&)>::__call_impl[abi:se190107])::$_1, bool (std::shared_ptr&)>>(std::__function::__policy_storage const*, std::shared_ptr&) @ 0x0000000015f9837e 21. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000165d6fc3 22. /build/src/Storages/StorageReplicatedMergeTree.cpp:3872: DB::StorageReplicatedMergeTree::processQueueEntry(std::shared_ptr) @ 0x0000000015efc18a 23. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001624c1b2 24. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000162f9c70 25. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x00000000162fa55a 26. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc6653 27. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000000fccc4c3 28. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc3d92 29. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fcca080 30. ? @ 0x00007fbc6213eac3 31. ? @ 0x00007fbc621d0850 (version 25.3.6.10636.altinitytest (altinity build)) 2025.07.28 12:01:23.933694 [ 3961 ] {} test_13.rmt2 (7f9b740d-015c-470e-8cc6-8ba33be0dc63): auto DB::StorageReplicatedMergeTree::processQueueEntry(ReplicatedMergeTreeQueue::SelectedEntryPtr)::(anonymous class)::operator()(LogEntryPtr &) const: Code: 86. DB::HTTPException: Received error from remote server http://146b4357c08d:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Ftest%2F01165%2Ftest_13%2Frmt%2Freplicas%2F1&part=20250728_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.6.10636.altinitytest (altinity build)) '. (RECEIVED_ERROR_FROM_REMOTE_IO_SERVER), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.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 const&, int&&, String const&, unsigned long&&, String const&) @ 0x000000000feda8d9 4. /build/src/IO/HTTPCommon.cpp:104: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x000000000feda6e2 5. /build/src/IO/HTTPCommon.cpp:93: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x000000000feda537 6. /build/src/IO/ReadWriteBufferFromHTTP.cpp:277: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x000000001184a4c4 7. /build/src/IO/ReadWriteBufferFromHTTP.cpp:285: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x000000001184a615 8. /build/src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x000000001184ae59 9. /build/src/IO/ReadWriteBufferFromHTTP.cpp:472: void std::__function::__policy_invoker::__call_impl[abi:se190107]>(std::__function::__policy_storage const*) @ 0x000000001184cedd 10. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001184858b 11. /build/src/IO/ReadWriteBufferFromHTTP.cpp:465: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x000000001184bf0b 12. /build/src/IO/ReadBuffer.h:60: DB::ReadBuffer::next() @ 0x000000000a148c7b 13. /build/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) @ 0x0000000011849fb2 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]>&)>&, 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&) @ 0x0000000011841980 15. /build/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) @ 0x000000001621208e 16. /build/src/Storages/StorageReplicatedMergeTree.cpp:5228: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl[abi:se190107] const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000015f9a5fe 17. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000015ed8bfd 18. /build/src/Storages/StorageReplicatedMergeTree.cpp:2514: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x0000000015ec9aab 19. /build/src/Storages/StorageReplicatedMergeTree.cpp:2349: DB::StorageReplicatedMergeTree::executeLogEntry(DB::ReplicatedMergeTreeLogEntry&) @ 0x0000000015eba91b 20. /build/src/Storages/StorageReplicatedMergeTree.cpp:3876: bool std::__function::__policy_invoker&)>::__call_impl[abi:se190107])::$_1, bool (std::shared_ptr&)>>(std::__function::__policy_storage const*, std::shared_ptr&) @ 0x0000000015f9837e 21. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000165d6fc3 22. /build/src/Storages/StorageReplicatedMergeTree.cpp:3872: DB::StorageReplicatedMergeTree::processQueueEntry(std::shared_ptr) @ 0x0000000015efc18a 23. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001624c1b2 24. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000162f9c70 25. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x00000000162fa55a 26. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc6653 27. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000000fccc4c3 28. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc3d92 29. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fcca080 30. ? @ 0x00007fbc6213eac3 31. ? @ 0x00007fbc621d0850 (version 25.3.6.10636.altinitytest (altinity build)) 2025.07.28 12:01:23.999601 [ 17252 ] {ae60ff13-0424-46d5-86d0-cd57e5597342} executeQuery: Code: 70. DB::Exception: Value in column UInt16 cannot be safely converted into type UInt8: In scope SELECT accurateCast(257, 'UInt8'). (CANNOT_CONVERT_TYPE) (version 25.3.6.10636.altinitytest (altinity build)) (from [::1]:39342) (comment: 01601_accurate_cast.sql) (query 3, line 3) (in query: SELECT accurateCast(257, 'UInt8');), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000a06a8eb 4. /build/src/Functions/FunctionsConversion.h:1861: COW::immutable_ptr DB::detail::ConvertImpl, DB::DataTypeNumber, DB::detail::FunctionCastName, (DB::FormatSettings::DateTimeOverflowBehavior)0>::execute(std::vector> const&, std::shared_ptr const&, unsigned long, DB::detail::BehaviourOnErrorFromString, DB::detail::AccurateConvertStrategyAdditions) @ 0x0000000012e021a6 5. /build/src/Functions/FunctionsConversion.h:3582: 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 @ 0x0000000012e00faf 6. /build/src/Core/callOnTypeIndex.h:253: 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 @ 0x0000000012e00b54 7. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: COW::immutable_ptr std::__function::__policy_invoker::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)>::__call_impl[abi:se190107]::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) @ 0x0000000012e00a4c 8. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000012ddcb1b 9. /build/src/Functions/IFunction.h:57: DB::IExecutableFunction::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000a08134a 10. /build/src/Functions/IFunction.cpp:351: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d93b02 11. /build/src/Functions/IFunction.cpp:177: DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d93698 12. /build/src/Functions/IFunction.cpp:343: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d93aad 13. /build/src/Functions/IFunction.cpp:424: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d94e1b 14. /build/src/Functions/IFunction.cpp:498: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d95c72 15. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3567: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000014034494 16. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3838: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000014019a9e 17. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3980: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000014018e31 18. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:4304: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000014042fa7 19. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5605: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000014013749 20. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000140127f9 21. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000014011fce 22. /build/src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000001406ce8a 23. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000014973b42 24. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000001497268d 25. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000014974d24 26. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001492924b 27. /build/src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88641 28. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 29. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 30. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 31. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 2025.07.28 12:01:24.006956 [ 17252 ] {} TCPHandler: Code: 70. DB::Exception: Value in column UInt16 cannot be safely converted into type UInt8: In scope SELECT accurateCast(257, 'UInt8'). (CANNOT_CONVERT_TYPE), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000a06a8eb 4. /build/src/Functions/FunctionsConversion.h:1861: COW::immutable_ptr DB::detail::ConvertImpl, DB::DataTypeNumber, DB::detail::FunctionCastName, (DB::FormatSettings::DateTimeOverflowBehavior)0>::execute(std::vector> const&, std::shared_ptr const&, unsigned long, DB::detail::BehaviourOnErrorFromString, DB::detail::AccurateConvertStrategyAdditions) @ 0x0000000012e021a6 5. /build/src/Functions/FunctionsConversion.h:3582: 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 @ 0x0000000012e00faf 6. /build/src/Core/callOnTypeIndex.h:253: 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 @ 0x0000000012e00b54 7. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: COW::immutable_ptr std::__function::__policy_invoker::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)>::__call_impl[abi:se190107]::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) @ 0x0000000012e00a4c 8. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000012ddcb1b 9. /build/src/Functions/IFunction.h:57: DB::IExecutableFunction::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000a08134a 10. /build/src/Functions/IFunction.cpp:351: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d93b02 11. /build/src/Functions/IFunction.cpp:177: DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d93698 12. /build/src/Functions/IFunction.cpp:343: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d93aad 13. /build/src/Functions/IFunction.cpp:424: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d94e1b 14. /build/src/Functions/IFunction.cpp:498: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d95c72 15. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3567: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000014034494 16. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3838: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000014019a9e 17. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3980: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000014018e31 18. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:4304: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000014042fa7 19. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5605: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000014013749 20. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000140127f9 21. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000014011fce 22. /build/src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000001406ce8a 23. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000014973b42 24. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000001497268d 25. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000014974d24 26. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001492924b 27. /build/src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88641 28. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 29. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 30. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 31. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 2025.07.28 12:01:24.084314 [ 17203 ] {b70d888f-b011-41d0-a1fd-808d516b3602} executeQuery: Code: 396. DB::Exception: Limit for result exceeded, max rows: 100.00, current rows: 24.43 thousand. (TOO_MANY_ROWS_OR_BYTES) (version 25.3.6.10636.altinitytest (altinity build)) (from [::1]:39364) (comment: 01131_max_rows_to_sort.sql) (query 2, line 2) (in query: SELECT * FROM system.numbers ORDER BY number;), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, char const*&, String&&, String&&) @ 0x0000000013bd4e0b 4. /build/src/QueryPipeline/SizeLimits.cpp:32: DB::SizeLimits::check(unsigned long, unsigned long, char const*, int, int) const @ 0x0000000013bd47b2 5. /build/src/Processors/Transforms/LimitsCheckingTransform.cpp:45: DB::LimitsCheckingTransform::transform(DB::Chunk&) @ 0x0000000016c1d2fb 6. /build/src/Processors/ISimpleTransform.h:33: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000011a9a453 7. /build/src/Processors/ISimpleTransform.cpp:89: DB::ISimpleTransform::work() @ 0x000000001699fca0 8. /build/src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x00000000169bd00f 9. /build/src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x00000000169b2105 10. /build/src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeSingleThread(unsigned long) @ 0x00000000169b23be 11. /build/src/Processors/Executors/PipelineExecutor.cpp:454: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x00000000169b0be7 12. /build/src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x00000000169b03f4 13. /build/src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:se190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169bfeab 14. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc3d92 15. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fcca080 16. ? @ 0x00007fbc6213eac3 17. ? @ 0x00007fbc621d0850 2025.07.28 12:01:24.089780 [ 17203 ] {} TCPHandler: Code: 396. DB::Exception: Limit for result exceeded, max rows: 100.00, current rows: 24.43 thousand. (TOO_MANY_ROWS_OR_BYTES), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, char const*&, String&&, String&&) @ 0x0000000013bd4e0b 4. /build/src/QueryPipeline/SizeLimits.cpp:32: DB::SizeLimits::check(unsigned long, unsigned long, char const*, int, int) const @ 0x0000000013bd47b2 5. /build/src/Processors/Transforms/LimitsCheckingTransform.cpp:45: DB::LimitsCheckingTransform::transform(DB::Chunk&) @ 0x0000000016c1d2fb 6. /build/src/Processors/ISimpleTransform.h:33: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000011a9a453 7. /build/src/Processors/ISimpleTransform.cpp:89: DB::ISimpleTransform::work() @ 0x000000001699fca0 8. /build/src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x00000000169bd00f 9. /build/src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x00000000169b2105 10. /build/src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeSingleThread(unsigned long) @ 0x00000000169b23be 11. /build/src/Processors/Executors/PipelineExecutor.cpp:454: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x00000000169b0be7 12. /build/src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x00000000169b03f4 13. /build/src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:se190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169bfeab 14. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc3d92 15. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fcca080 16. ? @ 0x00007fbc6213eac3 17. ? @ 0x00007fbc621d0850 Job's origin stack trace: 0. /build/src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000000fc33b84 1. /build/src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000000fcc2ea7 2. /build/src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fcc535c 3. /build/src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000000fcc584d 4. /build/src/Common/ThreadPool.h:279: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x00000000169bf193 5. /build/src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x00000000169bf518 6. /build/src/Server/TCPHandler.cpp:1237: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x00000000168f1525 7. /build/src/Server/TCPHandler.cpp:678: DB::TCPHandler::runImpl() @ 0x00000000168e68e5 8. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 9. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 10. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 11. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 12. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 13. ? @ 0x00007fbc6213eac3 14. ? @ 0x00007fbc621d0850 2025.07.28 12:01:24.090551 [ 3977 ] {} test_13.rmt2 (7f9b740d-015c-470e-8cc6-8ba33be0dc63): auto DB::StorageReplicatedMergeTree::processQueueEntry(ReplicatedMergeTreeQueue::SelectedEntryPtr)::(anonymous class)::operator()(LogEntryPtr &) const: Code: 86. DB::HTTPException: Received error from remote server http://146b4357c08d:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Ftest%2F01165%2Ftest_13%2Frmt%2Freplicas%2F1&part=20250728_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.6.10636.altinitytest (altinity build)) '. (RECEIVED_ERROR_FROM_REMOTE_IO_SERVER), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.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 const&, int&&, String const&, unsigned long&&, String const&) @ 0x000000000feda8d9 4. /build/src/IO/HTTPCommon.cpp:104: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x000000000feda6e2 5. /build/src/IO/HTTPCommon.cpp:93: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x000000000feda537 6. /build/src/IO/ReadWriteBufferFromHTTP.cpp:277: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x000000001184a4c4 7. /build/src/IO/ReadWriteBufferFromHTTP.cpp:285: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x000000001184a615 8. /build/src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x000000001184ae59 9. /build/src/IO/ReadWriteBufferFromHTTP.cpp:472: void std::__function::__policy_invoker::__call_impl[abi:se190107]>(std::__function::__policy_storage const*) @ 0x000000001184cedd 10. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001184858b 11. /build/src/IO/ReadWriteBufferFromHTTP.cpp:465: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x000000001184bf0b 12. /build/src/IO/ReadBuffer.h:60: DB::ReadBuffer::next() @ 0x000000000a148c7b 13. /build/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) @ 0x0000000011849fb2 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]>&)>&, 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&) @ 0x0000000011841980 15. /build/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) @ 0x000000001621208e 16. /build/src/Storages/StorageReplicatedMergeTree.cpp:5228: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl[abi:se190107] const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000015f9a5fe 17. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000015ed8bfd 18. /build/src/Storages/StorageReplicatedMergeTree.cpp:2514: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x0000000015ec9aab 19. /build/src/Storages/StorageReplicatedMergeTree.cpp:2349: DB::StorageReplicatedMergeTree::executeLogEntry(DB::ReplicatedMergeTreeLogEntry&) @ 0x0000000015eba91b 20. /build/src/Storages/StorageReplicatedMergeTree.cpp:3876: bool std::__function::__policy_invoker&)>::__call_impl[abi:se190107])::$_1, bool (std::shared_ptr&)>>(std::__function::__policy_storage const*, std::shared_ptr&) @ 0x0000000015f9837e 21. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000165d6fc3 22. /build/src/Storages/StorageReplicatedMergeTree.cpp:3872: DB::StorageReplicatedMergeTree::processQueueEntry(std::shared_ptr) @ 0x0000000015efc18a 23. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001624c1b2 24. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000162f9c70 25. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x00000000162fa55a 26. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc6653 27. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000000fccc4c3 28. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc3d92 29. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fcca080 30. ? @ 0x00007fbc6213eac3 31. ? @ 0x00007fbc621d0850 (version 25.3.6.10636.altinitytest (altinity build)) 2025.07.28 12:01:24.124208 [ 17203 ] {75fd1496-ddb5-4bb3-a811-281e6123736d} 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.6.10636.altinitytest (altinity build)) (from [::1]:39364) (comment: 01131_max_rows_to_sort.sql) (query 4, line 5) (in query: SET max_block_size = 1000;), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000000a074fcb 4. /build/src/Interpreters/executeQuery.cpp:1338: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c8a380 5. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 6. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 7. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 8. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 9. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 10. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 11. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 12. ? @ 0x00007fbc6213eac3 13. ? @ 0x00007fbc621d0850 2025.07.28 12:01:24.134278 [ 17203 ] {} 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. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000000a074fcb 4. /build/src/Interpreters/executeQuery.cpp:1338: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c8a380 5. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 6. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 7. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 8. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 9. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 10. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 11. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 12. ? @ 0x00007fbc6213eac3 13. ? @ 0x00007fbc621d0850 2025.07.28 12:01:24.180537 [ 17252 ] {fbece4ed-cc78-4f57-953b-3ab35de77a78} executeQuery: Code: 70. DB::Exception: Value in column Int8 cannot be safely converted into type UInt16: In scope SELECT accurateCast(-1, 'UInt16'). (CANNOT_CONVERT_TYPE) (version 25.3.6.10636.altinitytest (altinity build)) (from [::1]:39342) (comment: 01601_accurate_cast.sql) (query 4, line 4) (in query: SELECT accurateCast(-1, 'UInt16');), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000a06a8eb 4. /build/src/Functions/FunctionsConversion.h:1861: 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) @ 0x0000000012e14728 5. /build/src/Functions/FunctionsConversion.h:3582: 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 @ 0x0000000012e102af 6. /build/src/Core/callOnTypeIndex.h:259: 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 @ 0x0000000012e0fb39 7. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: COW::immutable_ptr std::__function::__policy_invoker::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)>::__call_impl[abi:se190107]::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) @ 0x0000000012e0f9cc 8. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000012ddcb1b 9. /build/src/Functions/IFunction.h:57: DB::IExecutableFunction::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000a08134a 10. /build/src/Functions/IFunction.cpp:351: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d93b02 11. /build/src/Functions/IFunction.cpp:177: DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d93698 12. /build/src/Functions/IFunction.cpp:343: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d93aad 13. /build/src/Functions/IFunction.cpp:424: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d94e1b 14. /build/src/Functions/IFunction.cpp:498: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d95c72 15. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3567: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000014034494 16. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3838: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000014019a9e 17. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3980: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000014018e31 18. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:4304: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000014042fa7 19. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5605: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000014013749 20. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000140127f9 21. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000014011fce 22. /build/src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000001406ce8a 23. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000014973b42 24. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000001497268d 25. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000014974d24 26. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001492924b 27. /build/src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88641 28. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 29. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 30. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 31. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 2025.07.28 12:01:24.184124 [ 17252 ] {} TCPHandler: Code: 70. DB::Exception: Value in column Int8 cannot be safely converted into type UInt16: In scope SELECT accurateCast(-1, 'UInt16'). (CANNOT_CONVERT_TYPE), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000a06a8eb 4. /build/src/Functions/FunctionsConversion.h:1861: 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) @ 0x0000000012e14728 5. /build/src/Functions/FunctionsConversion.h:3582: 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 @ 0x0000000012e102af 6. /build/src/Core/callOnTypeIndex.h:259: 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 @ 0x0000000012e0fb39 7. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: COW::immutable_ptr std::__function::__policy_invoker::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)>::__call_impl[abi:se190107]::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) @ 0x0000000012e0f9cc 8. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000012ddcb1b 9. /build/src/Functions/IFunction.h:57: DB::IExecutableFunction::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000a08134a 10. /build/src/Functions/IFunction.cpp:351: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d93b02 11. /build/src/Functions/IFunction.cpp:177: DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d93698 12. /build/src/Functions/IFunction.cpp:343: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d93aad 13. /build/src/Functions/IFunction.cpp:424: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d94e1b 14. /build/src/Functions/IFunction.cpp:498: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d95c72 15. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3567: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000014034494 16. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3838: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000014019a9e 17. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3980: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000014018e31 18. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:4304: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000014042fa7 19. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5605: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000014013749 20. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000140127f9 21. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000014011fce 22. /build/src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000001406ce8a 23. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000014973b42 24. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000001497268d 25. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000014974d24 26. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001492924b 27. /build/src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88641 28. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 29. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 30. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 31. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 2025.07.28 12:01:24.584599 [ 3960 ] {} test_13.rmt2 (7f9b740d-015c-470e-8cc6-8ba33be0dc63): auto DB::StorageReplicatedMergeTree::processQueueEntry(ReplicatedMergeTreeQueue::SelectedEntryPtr)::(anonymous class)::operator()(LogEntryPtr &) const: Code: 86. DB::HTTPException: Received error from remote server http://146b4357c08d:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Ftest%2F01165%2Ftest_13%2Frmt%2Freplicas%2F1&part=20250728_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.6.10636.altinitytest (altinity build)) '. (RECEIVED_ERROR_FROM_REMOTE_IO_SERVER), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.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 const&, int&&, String const&, unsigned long&&, String const&) @ 0x000000000feda8d9 4. /build/src/IO/HTTPCommon.cpp:104: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x000000000feda6e2 5. /build/src/IO/HTTPCommon.cpp:93: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x000000000feda537 6. /build/src/IO/ReadWriteBufferFromHTTP.cpp:277: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x000000001184a4c4 7. /build/src/IO/ReadWriteBufferFromHTTP.cpp:285: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x000000001184a615 8. /build/src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x000000001184ae59 9. /build/src/IO/ReadWriteBufferFromHTTP.cpp:472: void std::__function::__policy_invoker::__call_impl[abi:se190107]>(std::__function::__policy_storage const*) @ 0x000000001184cedd 10. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001184858b 11. /build/src/IO/ReadWriteBufferFromHTTP.cpp:465: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x000000001184bf0b 12. /build/src/IO/ReadBuffer.h:60: DB::ReadBuffer::next() @ 0x000000000a148c7b 13. /build/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) @ 0x0000000011849fb2 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]>&)>&, 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&) @ 0x0000000011841980 15. /build/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) @ 0x000000001621208e 16. /build/src/Storages/StorageReplicatedMergeTree.cpp:5228: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl[abi:se190107] const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000015f9a5fe 17. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000015ed8bfd 18. /build/src/Storages/StorageReplicatedMergeTree.cpp:2514: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x0000000015ec9aab 19. /build/src/Storages/StorageReplicatedMergeTree.cpp:2349: DB::StorageReplicatedMergeTree::executeLogEntry(DB::ReplicatedMergeTreeLogEntry&) @ 0x0000000015eba91b 20. /build/src/Storages/StorageReplicatedMergeTree.cpp:3876: bool std::__function::__policy_invoker&)>::__call_impl[abi:se190107])::$_1, bool (std::shared_ptr&)>>(std::__function::__policy_storage const*, std::shared_ptr&) @ 0x0000000015f9837e 21. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000165d6fc3 22. /build/src/Storages/StorageReplicatedMergeTree.cpp:3872: DB::StorageReplicatedMergeTree::processQueueEntry(std::shared_ptr) @ 0x0000000015efc18a 23. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001624c1b2 24. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000162f9c70 25. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x00000000162fa55a 26. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc6653 27. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000000fccc4c3 28. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc3d92 29. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fcca080 30. ? @ 0x00007fbc6213eac3 31. ? @ 0x00007fbc621d0850 (version 25.3.6.10636.altinitytest (altinity build)) 2025.07.28 12:01:24.654577 [ 17252 ] {1856b4f7-a9ad-4c0c-acc7-db9420e6ed1a} executeQuery: Code: 70. DB::Exception: Value in column UInt32 cannot be safely converted into type UInt16: In scope SELECT accurateCast(65536, 'UInt16'). (CANNOT_CONVERT_TYPE) (version 25.3.6.10636.altinitytest (altinity build)) (from [::1]:39342) (comment: 01601_accurate_cast.sql) (query 6, line 6) (in query: SELECT accurateCast(65536, 'UInt16');), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000a06a8eb 4. /build/src/Functions/FunctionsConversion.h:1861: COW::immutable_ptr DB::detail::ConvertImpl, DB::DataTypeNumber, DB::detail::FunctionCastName, (DB::FormatSettings::DateTimeOverflowBehavior)0>::execute(std::vector> const&, std::shared_ptr const&, unsigned long, DB::detail::BehaviourOnErrorFromString, DB::detail::AccurateConvertStrategyAdditions) @ 0x0000000012e11848 5. /build/src/Functions/FunctionsConversion.h:3582: 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 @ 0x0000000012e0ff2f 6. /build/src/Core/callOnTypeIndex.h:254: 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 @ 0x0000000012e0fb28 7. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: COW::immutable_ptr std::__function::__policy_invoker::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)>::__call_impl[abi:se190107]::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) @ 0x0000000012e0f9cc 8. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000012ddcb1b 9. /build/src/Functions/IFunction.h:57: DB::IExecutableFunction::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000a08134a 10. /build/src/Functions/IFunction.cpp:351: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d93b02 11. /build/src/Functions/IFunction.cpp:177: DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d93698 12. /build/src/Functions/IFunction.cpp:343: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d93aad 13. /build/src/Functions/IFunction.cpp:424: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d94e1b 14. /build/src/Functions/IFunction.cpp:498: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d95c72 15. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3567: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000014034494 16. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3838: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000014019a9e 17. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3980: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000014018e31 18. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:4304: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000014042fa7 19. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5605: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000014013749 20. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000140127f9 21. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000014011fce 22. /build/src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000001406ce8a 23. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000014973b42 24. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000001497268d 25. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000014974d24 26. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001492924b 27. /build/src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88641 28. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 29. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 30. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 31. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 2025.07.28 12:01:24.685743 [ 17252 ] {} TCPHandler: Code: 70. DB::Exception: Value in column UInt32 cannot be safely converted into type UInt16: In scope SELECT accurateCast(65536, 'UInt16'). (CANNOT_CONVERT_TYPE), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000a06a8eb 4. /build/src/Functions/FunctionsConversion.h:1861: COW::immutable_ptr DB::detail::ConvertImpl, DB::DataTypeNumber, DB::detail::FunctionCastName, (DB::FormatSettings::DateTimeOverflowBehavior)0>::execute(std::vector> const&, std::shared_ptr const&, unsigned long, DB::detail::BehaviourOnErrorFromString, DB::detail::AccurateConvertStrategyAdditions) @ 0x0000000012e11848 5. /build/src/Functions/FunctionsConversion.h:3582: 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 @ 0x0000000012e0ff2f 6. /build/src/Core/callOnTypeIndex.h:254: 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 @ 0x0000000012e0fb28 7. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: COW::immutable_ptr std::__function::__policy_invoker::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)>::__call_impl[abi:se190107]::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) @ 0x0000000012e0f9cc 8. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000012ddcb1b 9. /build/src/Functions/IFunction.h:57: DB::IExecutableFunction::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000a08134a 10. /build/src/Functions/IFunction.cpp:351: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d93b02 11. /build/src/Functions/IFunction.cpp:177: DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d93698 12. /build/src/Functions/IFunction.cpp:343: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d93aad 13. /build/src/Functions/IFunction.cpp:424: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d94e1b 14. /build/src/Functions/IFunction.cpp:498: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d95c72 15. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3567: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000014034494 16. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3838: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000014019a9e 17. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3980: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000014018e31 18. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:4304: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000014042fa7 19. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5605: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000014013749 20. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000140127f9 21. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000014011fce 22. /build/src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000001406ce8a 23. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000014973b42 24. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000001497268d 25. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000014974d24 26. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001492924b 27. /build/src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88641 28. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 29. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 30. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 31. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 2025.07.28 12:01:24.902509 [ 17252 ] {65191c43-a3e7-46cd-85fe-edf20713d97e} executeQuery: Code: 70. DB::Exception: Value in column Int8 cannot be safely converted into type UInt32: In scope SELECT accurateCast(-1, 'UInt32'). (CANNOT_CONVERT_TYPE) (version 25.3.6.10636.altinitytest (altinity build)) (from [::1]:39342) (comment: 01601_accurate_cast.sql) (query 7, line 7) (in query: SELECT accurateCast(-1, 'UInt32');), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000a06a8eb 4. /build/src/Functions/FunctionsConversion.h:1861: 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) @ 0x0000000012e21e48 5. /build/src/Functions/FunctionsConversion.h:3582: 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 @ 0x0000000012e1db6f 6. /build/src/Core/callOnTypeIndex.h:259: 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 @ 0x0000000012e1d3f9 7. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: COW::immutable_ptr std::__function::__policy_invoker::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)>::__call_impl[abi:se190107]::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) @ 0x0000000012e1d28c 8. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000012ddcb1b 9. /build/src/Functions/IFunction.h:57: DB::IExecutableFunction::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000a08134a 10. /build/src/Functions/IFunction.cpp:351: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d93b02 11. /build/src/Functions/IFunction.cpp:177: DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d93698 12. /build/src/Functions/IFunction.cpp:343: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d93aad 13. /build/src/Functions/IFunction.cpp:424: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d94e1b 14. /build/src/Functions/IFunction.cpp:498: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d95c72 15. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3567: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000014034494 16. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3838: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000014019a9e 17. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3980: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000014018e31 18. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:4304: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000014042fa7 19. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5605: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000014013749 20. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000140127f9 21. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000014011fce 22. /build/src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000001406ce8a 23. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000014973b42 24. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000001497268d 25. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000014974d24 26. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001492924b 27. /build/src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88641 28. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 29. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 30. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 31. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 2025.07.28 12:01:24.919311 [ 17252 ] {} TCPHandler: Code: 70. DB::Exception: Value in column Int8 cannot be safely converted into type UInt32: In scope SELECT accurateCast(-1, 'UInt32'). (CANNOT_CONVERT_TYPE), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000a06a8eb 4. /build/src/Functions/FunctionsConversion.h:1861: 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) @ 0x0000000012e21e48 5. /build/src/Functions/FunctionsConversion.h:3582: 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 @ 0x0000000012e1db6f 6. /build/src/Core/callOnTypeIndex.h:259: 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 @ 0x0000000012e1d3f9 7. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: COW::immutable_ptr std::__function::__policy_invoker::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)>::__call_impl[abi:se190107]::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) @ 0x0000000012e1d28c 8. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000012ddcb1b 9. /build/src/Functions/IFunction.h:57: DB::IExecutableFunction::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000a08134a 10. /build/src/Functions/IFunction.cpp:351: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d93b02 11. /build/src/Functions/IFunction.cpp:177: DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d93698 12. /build/src/Functions/IFunction.cpp:343: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d93aad 13. /build/src/Functions/IFunction.cpp:424: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d94e1b 14. /build/src/Functions/IFunction.cpp:498: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d95c72 15. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3567: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000014034494 16. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3838: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000014019a9e 17. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3980: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000014018e31 18. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:4304: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000014042fa7 19. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5605: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000014013749 20. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000140127f9 21. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000014011fce 22. /build/src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000001406ce8a 23. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000014973b42 24. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000001497268d 25. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000014974d24 26. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001492924b 27. /build/src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88641 28. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 29. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 30. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 31. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 2025.07.28 12:01:25.118684 [ 17252 ] {61e9fc3e-b272-493d-8540-eab0375eed81} executeQuery: Code: 70. DB::Exception: Value in column UInt64 cannot be safely converted into type UInt32: In scope SELECT accurateCast(4294967296, 'UInt32'). (CANNOT_CONVERT_TYPE) (version 25.3.6.10636.altinitytest (altinity build)) (from [::1]:39342) (comment: 01601_accurate_cast.sql) (query 9, line 9) (in query: SELECT accurateCast(4294967296, 'UInt32');), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000a06a8eb 4. /build/src/Functions/FunctionsConversion.h:1861: COW::immutable_ptr DB::detail::ConvertImpl, DB::DataTypeNumber, DB::detail::FunctionCastName, (DB::FormatSettings::DateTimeOverflowBehavior)0>::execute(std::vector> const&, std::shared_ptr const&, unsigned long, DB::detail::BehaviourOnErrorFromString, DB::detail::AccurateConvertStrategyAdditions) @ 0x0000000012e1f9a8 5. /build/src/Functions/FunctionsConversion.h:3582: 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 @ 0x0000000012e1d8cf 6. /build/src/Core/callOnTypeIndex.h:255: 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 @ 0x0000000012e1d3d4 7. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: COW::immutable_ptr std::__function::__policy_invoker::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)>::__call_impl[abi:se190107]::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) @ 0x0000000012e1d28c 8. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000012ddcb1b 9. /build/src/Functions/IFunction.h:57: DB::IExecutableFunction::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000a08134a 10. /build/src/Functions/IFunction.cpp:351: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d93b02 11. /build/src/Functions/IFunction.cpp:177: DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d93698 12. /build/src/Functions/IFunction.cpp:343: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d93aad 13. /build/src/Functions/IFunction.cpp:424: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d94e1b 14. /build/src/Functions/IFunction.cpp:498: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d95c72 15. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3567: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000014034494 16. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3838: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000014019a9e 17. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3980: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000014018e31 18. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:4304: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000014042fa7 19. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5605: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000014013749 20. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000140127f9 21. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000014011fce 22. /build/src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000001406ce8a 23. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000014973b42 24. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000001497268d 25. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000014974d24 26. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001492924b 27. /build/src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88641 28. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 29. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 30. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 31. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 2025.07.28 12:01:25.134259 [ 17252 ] {} TCPHandler: Code: 70. DB::Exception: Value in column UInt64 cannot be safely converted into type UInt32: In scope SELECT accurateCast(4294967296, 'UInt32'). (CANNOT_CONVERT_TYPE), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000a06a8eb 4. /build/src/Functions/FunctionsConversion.h:1861: COW::immutable_ptr DB::detail::ConvertImpl, DB::DataTypeNumber, DB::detail::FunctionCastName, (DB::FormatSettings::DateTimeOverflowBehavior)0>::execute(std::vector> const&, std::shared_ptr const&, unsigned long, DB::detail::BehaviourOnErrorFromString, DB::detail::AccurateConvertStrategyAdditions) @ 0x0000000012e1f9a8 5. /build/src/Functions/FunctionsConversion.h:3582: 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 @ 0x0000000012e1d8cf 6. /build/src/Core/callOnTypeIndex.h:255: 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 @ 0x0000000012e1d3d4 7. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: COW::immutable_ptr std::__function::__policy_invoker::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)>::__call_impl[abi:se190107]::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) @ 0x0000000012e1d28c 8. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000012ddcb1b 9. /build/src/Functions/IFunction.h:57: DB::IExecutableFunction::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000a08134a 10. /build/src/Functions/IFunction.cpp:351: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d93b02 11. /build/src/Functions/IFunction.cpp:177: DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d93698 12. /build/src/Functions/IFunction.cpp:343: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d93aad 13. /build/src/Functions/IFunction.cpp:424: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d94e1b 14. /build/src/Functions/IFunction.cpp:498: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d95c72 15. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3567: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000014034494 16. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3838: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000014019a9e 17. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3980: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000014018e31 18. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:4304: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000014042fa7 19. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5605: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000014013749 20. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000140127f9 21. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000014011fce 22. /build/src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000001406ce8a 23. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000014973b42 24. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000001497268d 25. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000014974d24 26. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001492924b 27. /build/src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88641 28. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 29. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 30. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 31. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 2025.07.28 12:01:25.371267 [ 17252 ] {f3348703-7d17-4270-b9c9-be7672da1f05} executeQuery: Code: 70. DB::Exception: Value in column Int8 cannot be safely converted into type UInt64: In scope SELECT accurateCast(-1, 'UInt64'). (CANNOT_CONVERT_TYPE) (version 25.3.6.10636.altinitytest (altinity build)) (from [::1]:39342) (comment: 01601_accurate_cast.sql) (query 10, line 10) (in query: SELECT accurateCast(-1, 'UInt64');), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000a06a8eb 4. /build/src/Functions/FunctionsConversion.h:1861: 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) @ 0x0000000012e2f388 5. /build/src/Functions/FunctionsConversion.h:3582: 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 @ 0x0000000012e2b28f 6. /build/src/Core/callOnTypeIndex.h:259: 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 @ 0x0000000012e2ab19 7. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: COW::immutable_ptr std::__function::__policy_invoker::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)>::__call_impl[abi:se190107]::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) @ 0x0000000012e2a9ac 8. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000012ddcb1b 9. /build/src/Functions/IFunction.h:57: DB::IExecutableFunction::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000a08134a 10. /build/src/Functions/IFunction.cpp:351: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d93b02 11. /build/src/Functions/IFunction.cpp:177: DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d93698 12. /build/src/Functions/IFunction.cpp:343: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d93aad 13. /build/src/Functions/IFunction.cpp:424: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d94e1b 14. /build/src/Functions/IFunction.cpp:498: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d95c72 15. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3567: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000014034494 16. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3838: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000014019a9e 17. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3980: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000014018e31 18. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:4304: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000014042fa7 19. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5605: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000014013749 20. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000140127f9 21. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000014011fce 22. /build/src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000001406ce8a 23. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000014973b42 24. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000001497268d 25. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000014974d24 26. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001492924b 27. /build/src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88641 28. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 29. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 30. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 31. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 2025.07.28 12:01:25.403929 [ 17252 ] {} TCPHandler: Code: 70. DB::Exception: Value in column Int8 cannot be safely converted into type UInt64: In scope SELECT accurateCast(-1, 'UInt64'). (CANNOT_CONVERT_TYPE), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000a06a8eb 4. /build/src/Functions/FunctionsConversion.h:1861: 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) @ 0x0000000012e2f388 5. /build/src/Functions/FunctionsConversion.h:3582: 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 @ 0x0000000012e2b28f 6. /build/src/Core/callOnTypeIndex.h:259: 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 @ 0x0000000012e2ab19 7. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: COW::immutable_ptr std::__function::__policy_invoker::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)>::__call_impl[abi:se190107]::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) @ 0x0000000012e2a9ac 8. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000012ddcb1b 9. /build/src/Functions/IFunction.h:57: DB::IExecutableFunction::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000a08134a 10. /build/src/Functions/IFunction.cpp:351: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d93b02 11. /build/src/Functions/IFunction.cpp:177: DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d93698 12. /build/src/Functions/IFunction.cpp:343: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d93aad 13. /build/src/Functions/IFunction.cpp:424: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d94e1b 14. /build/src/Functions/IFunction.cpp:498: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d95c72 15. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3567: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000014034494 16. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3838: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000014019a9e 17. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3980: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000014018e31 18. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:4304: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000014042fa7 19. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5605: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000014013749 20. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000140127f9 21. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000014011fce 22. /build/src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000001406ce8a 23. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000014973b42 24. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000001497268d 25. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000014974d24 26. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001492924b 27. /build/src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88641 28. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 29. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 30. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 31. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 2025.07.28 12:01:25.507521 [ 3976 ] {} test_13.rmt2 (7f9b740d-015c-470e-8cc6-8ba33be0dc63): auto DB::StorageReplicatedMergeTree::processQueueEntry(ReplicatedMergeTreeQueue::SelectedEntryPtr)::(anonymous class)::operator()(LogEntryPtr &) const: Code: 86. DB::HTTPException: Received error from remote server http://146b4357c08d:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Ftest%2F01165%2Ftest_13%2Frmt%2Freplicas%2F1&part=20250728_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.6.10636.altinitytest (altinity build)) '. (RECEIVED_ERROR_FROM_REMOTE_IO_SERVER), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.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 const&, int&&, String const&, unsigned long&&, String const&) @ 0x000000000feda8d9 4. /build/src/IO/HTTPCommon.cpp:104: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x000000000feda6e2 5. /build/src/IO/HTTPCommon.cpp:93: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x000000000feda537 6. /build/src/IO/ReadWriteBufferFromHTTP.cpp:277: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x000000001184a4c4 7. /build/src/IO/ReadWriteBufferFromHTTP.cpp:285: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x000000001184a615 8. /build/src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x000000001184ae59 9. /build/src/IO/ReadWriteBufferFromHTTP.cpp:472: void std::__function::__policy_invoker::__call_impl[abi:se190107]>(std::__function::__policy_storage const*) @ 0x000000001184cedd 10. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001184858b 11. /build/src/IO/ReadWriteBufferFromHTTP.cpp:465: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x000000001184bf0b 12. /build/src/IO/ReadBuffer.h:60: DB::ReadBuffer::next() @ 0x000000000a148c7b 13. /build/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) @ 0x0000000011849fb2 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]>&)>&, 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&) @ 0x0000000011841980 15. /build/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) @ 0x000000001621208e 16. /build/src/Storages/StorageReplicatedMergeTree.cpp:5228: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl[abi:se190107] const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000015f9a5fe 17. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000015ed8bfd 18. /build/src/Storages/StorageReplicatedMergeTree.cpp:2514: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x0000000015ec9aab 19. /build/src/Storages/StorageReplicatedMergeTree.cpp:2349: DB::StorageReplicatedMergeTree::executeLogEntry(DB::ReplicatedMergeTreeLogEntry&) @ 0x0000000015eba91b 20. /build/src/Storages/StorageReplicatedMergeTree.cpp:3876: bool std::__function::__policy_invoker&)>::__call_impl[abi:se190107])::$_1, bool (std::shared_ptr&)>>(std::__function::__policy_storage const*, std::shared_ptr&) @ 0x0000000015f9837e 21. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000165d6fc3 22. /build/src/Storages/StorageReplicatedMergeTree.cpp:3872: DB::StorageReplicatedMergeTree::processQueueEntry(std::shared_ptr) @ 0x0000000015efc18a 23. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001624c1b2 24. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000162f9c70 25. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x00000000162fa55a 26. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc6653 27. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000000fccc4c3 28. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc3d92 29. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fcca080 30. ? @ 0x00007fbc6213eac3 31. ? @ 0x00007fbc621d0850 (version 25.3.6.10636.altinitytest (altinity build)) 2025.07.28 12:01:25.954613 [ 17252 ] {d0f8ce03-4a51-46af-9eb2-48a26e467aeb} executeQuery: Code: 70. DB::Exception: Value in column Int8 cannot be safely converted into type UInt256: In scope SELECT accurateCast(-1, 'UInt256'). (CANNOT_CONVERT_TYPE) (version 25.3.6.10636.altinitytest (altinity build)) (from [::1]:39342) (comment: 01601_accurate_cast.sql) (query 12, line 12) (in query: SELECT accurateCast(-1, 'UInt256');), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000a06a8eb 4. /build/src/Functions/FunctionsConversion.h:1861: 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) @ 0x0000000012e4cbd1 5. /build/src/Functions/FunctionsConversion.h:3582: 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 @ 0x0000000012e4786f 6. /build/src/Core/callOnTypeIndex.h:259: 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 @ 0x0000000012e470f9 7. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: COW::immutable_ptr std::__function::__policy_invoker::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)>::__call_impl[abi:se190107]::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) @ 0x0000000012e46f8c 8. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000012ddcb1b 9. /build/src/Functions/IFunction.h:57: DB::IExecutableFunction::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000a08134a 10. /build/src/Functions/IFunction.cpp:351: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d93b02 11. /build/src/Functions/IFunction.cpp:177: DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d93698 12. /build/src/Functions/IFunction.cpp:343: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d93aad 13. /build/src/Functions/IFunction.cpp:424: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d94e1b 14. /build/src/Functions/IFunction.cpp:498: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d95c72 15. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3567: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000014034494 16. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3838: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000014019a9e 17. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3980: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000014018e31 18. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:4304: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000014042fa7 19. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5605: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000014013749 20. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000140127f9 21. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000014011fce 22. /build/src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000001406ce8a 23. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000014973b42 24. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000001497268d 25. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000014974d24 26. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001492924b 27. /build/src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88641 28. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 29. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 30. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 31. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 2025.07.28 12:01:25.979978 [ 17252 ] {} TCPHandler: Code: 70. DB::Exception: Value in column Int8 cannot be safely converted into type UInt256: In scope SELECT accurateCast(-1, 'UInt256'). (CANNOT_CONVERT_TYPE), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000a06a8eb 4. /build/src/Functions/FunctionsConversion.h:1861: 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) @ 0x0000000012e4cbd1 5. /build/src/Functions/FunctionsConversion.h:3582: 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 @ 0x0000000012e4786f 6. /build/src/Core/callOnTypeIndex.h:259: 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 @ 0x0000000012e470f9 7. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: COW::immutable_ptr std::__function::__policy_invoker::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)>::__call_impl[abi:se190107]::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) @ 0x0000000012e46f8c 8. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000012ddcb1b 9. /build/src/Functions/IFunction.h:57: DB::IExecutableFunction::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000a08134a 10. /build/src/Functions/IFunction.cpp:351: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d93b02 11. /build/src/Functions/IFunction.cpp:177: DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d93698 12. /build/src/Functions/IFunction.cpp:343: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d93aad 13. /build/src/Functions/IFunction.cpp:424: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d94e1b 14. /build/src/Functions/IFunction.cpp:498: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d95c72 15. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3567: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000014034494 16. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3838: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000014019a9e 17. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3980: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000014018e31 18. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:4304: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000014042fa7 19. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5605: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000014013749 20. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000140127f9 21. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000014011fce 22. /build/src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000001406ce8a 23. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000014973b42 24. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000001497268d 25. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000014974d24 26. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001492924b 27. /build/src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88641 28. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 29. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 30. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 31. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 2025.07.28 12:01:26.288980 [ 3972 ] {} test_13.rmt2 (7f9b740d-015c-470e-8cc6-8ba33be0dc63): auto DB::StorageReplicatedMergeTree::processQueueEntry(ReplicatedMergeTreeQueue::SelectedEntryPtr)::(anonymous class)::operator()(LogEntryPtr &) const: Code: 86. DB::HTTPException: Received error from remote server http://146b4357c08d:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Ftest%2F01165%2Ftest_13%2Frmt%2Freplicas%2F1&part=20250728_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.6.10636.altinitytest (altinity build)) '. (RECEIVED_ERROR_FROM_REMOTE_IO_SERVER), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.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 const&, int&&, String const&, unsigned long&&, String const&) @ 0x000000000feda8d9 4. /build/src/IO/HTTPCommon.cpp:104: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x000000000feda6e2 5. /build/src/IO/HTTPCommon.cpp:93: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x000000000feda537 6. /build/src/IO/ReadWriteBufferFromHTTP.cpp:277: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x000000001184a4c4 7. /build/src/IO/ReadWriteBufferFromHTTP.cpp:285: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x000000001184a615 8. /build/src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x000000001184ae59 9. /build/src/IO/ReadWriteBufferFromHTTP.cpp:472: void std::__function::__policy_invoker::__call_impl[abi:se190107]>(std::__function::__policy_storage const*) @ 0x000000001184cedd 10. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001184858b 11. /build/src/IO/ReadWriteBufferFromHTTP.cpp:465: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x000000001184bf0b 12. /build/src/IO/ReadBuffer.h:60: DB::ReadBuffer::next() @ 0x000000000a148c7b 13. /build/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) @ 0x0000000011849fb2 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]>&)>&, 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&) @ 0x0000000011841980 15. /build/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) @ 0x000000001621208e 16. /build/src/Storages/StorageReplicatedMergeTree.cpp:5228: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl[abi:se190107] const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000015f9a5fe 17. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000015ed8bfd 18. /build/src/Storages/StorageReplicatedMergeTree.cpp:2514: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x0000000015ec9aab 19. /build/src/Storages/StorageReplicatedMergeTree.cpp:2349: DB::StorageReplicatedMergeTree::executeLogEntry(DB::ReplicatedMergeTreeLogEntry&) @ 0x0000000015eba91b 20. /build/src/Storages/StorageReplicatedMergeTree.cpp:3876: bool std::__function::__policy_invoker&)>::__call_impl[abi:se190107])::$_1, bool (std::shared_ptr&)>>(std::__function::__policy_storage const*, std::shared_ptr&) @ 0x0000000015f9837e 21. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000165d6fc3 22. /build/src/Storages/StorageReplicatedMergeTree.cpp:3872: DB::StorageReplicatedMergeTree::processQueueEntry(std::shared_ptr) @ 0x0000000015efc18a 23. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001624c1b2 24. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000162f9c70 25. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x00000000162fa55a 26. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc6653 27. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000000fccc4c3 28. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc3d92 29. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fcca080 30. ? @ 0x00007fbc6213eac3 31. ? @ 0x00007fbc621d0850 (version 25.3.6.10636.altinitytest (altinity build)) 2025.07.28 12:01:26.343485 [ 3964 ] {} test_13.rmt2 (7f9b740d-015c-470e-8cc6-8ba33be0dc63): auto DB::StorageReplicatedMergeTree::processQueueEntry(ReplicatedMergeTreeQueue::SelectedEntryPtr)::(anonymous class)::operator()(LogEntryPtr &) const: Code: 86. DB::HTTPException: Received error from remote server http://146b4357c08d:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Ftest%2F01165%2Ftest_13%2Frmt%2Freplicas%2F1&part=20250728_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.6.10636.altinitytest (altinity build)) '. (RECEIVED_ERROR_FROM_REMOTE_IO_SERVER), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.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 const&, int&&, String const&, unsigned long&&, String const&) @ 0x000000000feda8d9 4. /build/src/IO/HTTPCommon.cpp:104: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x000000000feda6e2 5. /build/src/IO/HTTPCommon.cpp:93: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x000000000feda537 6. /build/src/IO/ReadWriteBufferFromHTTP.cpp:277: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x000000001184a4c4 7. /build/src/IO/ReadWriteBufferFromHTTP.cpp:285: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x000000001184a615 8. /build/src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x000000001184ae59 9. /build/src/IO/ReadWriteBufferFromHTTP.cpp:472: void std::__function::__policy_invoker::__call_impl[abi:se190107]>(std::__function::__policy_storage const*) @ 0x000000001184cedd 10. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001184858b 11. /build/src/IO/ReadWriteBufferFromHTTP.cpp:465: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x000000001184bf0b 12. /build/src/IO/ReadBuffer.h:60: DB::ReadBuffer::next() @ 0x000000000a148c7b 13. /build/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) @ 0x0000000011849fb2 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]>&)>&, 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&) @ 0x0000000011841980 15. /build/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) @ 0x000000001621208e 16. /build/src/Storages/StorageReplicatedMergeTree.cpp:5228: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl[abi:se190107] const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000015f9a5fe 17. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000015ed8bfd 18. /build/src/Storages/StorageReplicatedMergeTree.cpp:2514: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x0000000015ec9aab 19. /build/src/Storages/StorageReplicatedMergeTree.cpp:2349: DB::StorageReplicatedMergeTree::executeLogEntry(DB::ReplicatedMergeTreeLogEntry&) @ 0x0000000015eba91b 20. /build/src/Storages/StorageReplicatedMergeTree.cpp:3876: bool std::__function::__policy_invoker&)>::__call_impl[abi:se190107])::$_1, bool (std::shared_ptr&)>>(std::__function::__policy_storage const*, std::shared_ptr&) @ 0x0000000015f9837e 21. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000165d6fc3 22. /build/src/Storages/StorageReplicatedMergeTree.cpp:3872: DB::StorageReplicatedMergeTree::processQueueEntry(std::shared_ptr) @ 0x0000000015efc18a 23. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001624c1b2 24. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000162f9c70 25. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x00000000162fa55a 26. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc6653 27. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000000fccc4c3 28. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc3d92 29. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fcca080 30. ? @ 0x00007fbc6213eac3 31. ? @ 0x00007fbc621d0850 (version 25.3.6.10636.altinitytest (altinity build)) 2025.07.28 12:01:26.450947 [ 17252 ] {8358c069-51ca-4326-bd7b-09d2efb961d6} executeQuery: Code: 70. DB::Exception: Value in column Int16 cannot be safely converted into type Int8: In scope SELECT accurateCast(-129, 'Int8'). (CANNOT_CONVERT_TYPE) (version 25.3.6.10636.altinitytest (altinity build)) (from [::1]:39342) (comment: 01601_accurate_cast.sql) (query 14, line 15) (in query: SELECT accurateCast(-129, 'Int8');), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000a06a8eb 4. /build/src/Functions/FunctionsConversion.h:1861: COW::immutable_ptr> DB::detail::ConvertImpl, DB::DataTypeNumber<_BitInt(8)>, DB::detail::FunctionCastName, (DB::FormatSettings::DateTimeOverflowBehavior)0>::execute(std::vector> const&, std::vector::shared_ptr const&, unsigned long, DB::detail::BehaviourOnErrorFromString, DB::detail::AccurateConvertStrategyAdditions) @ 0x0000000012e5c5d2 5. /build/src/Functions/FunctionsConversion.h:3582: bool std::function::immutable_ptr> (std::function::vector>&, std::function::shared_ptr const&, DB::ColumnNullable const*, unsigned long)> DB::detail::FunctionCast::createWrapper>(DB::ColumnNullable, DB::DataTypeNumber<_BitInt(8)> const*, bool) const::'lambda'(std::function::shared_ptr, DB::ColumnNullable, COW::immutable_ptr> (std::function::vector>&, std::function::shared_ptr const&, DB::ColumnNullable const*, unsigned long), unsigned long)::operator()(std::function::shared_ptr, DB::ColumnNullable, COW::immutable_ptr> (std::function::vector>&, std::function::shared_ptr const&, DB::ColumnNullable const*, unsigned long), unsigned long) const::'lambda'(DB::DataTypeNumber<_BitInt(8)> const*&)::operator(), std>>('lambda'(DB::DataTypeNumber<_BitInt(8)> const*&)) const @ 0x0000000012e5788f 6. /build/src/Core/callOnTypeIndex.h:260: std::function::immutable_ptr> (std::function::vector>&, std::function::shared_ptr const&, DB::ColumnNullable const*, unsigned long)> DB::detail::FunctionCast::createWrapper>(DB::ColumnNullable, DB::DataTypeNumber<_BitInt(8)> const*, bool) const::'lambda'(std::function::shared_ptr, DB::ColumnNullable, COW::immutable_ptr> (std::function::vector>&, std::function::shared_ptr const&, DB::ColumnNullable const*, unsigned long), unsigned long)::operator()(std::function::shared_ptr, DB::ColumnNullable, COW::immutable_ptr> (std::function::vector>&, std::function::shared_ptr const&, DB::ColumnNullable const*, unsigned long), unsigned long) const @ 0x0000000012e5704a 7. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: COW::immutable_ptr std::__function::__policy_invoker::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)>::__call_impl[abi:se190107]::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)> DB::detail::FunctionCast::createWrapper>(std::shared_ptr const&, DB::DataTypeNumber<_BitInt(8)> 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) @ 0x0000000012e56ecc 8. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000012ddcb1b 9. /build/src/Functions/IFunction.h:57: DB::IExecutableFunction::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000a08134a 10. /build/src/Functions/IFunction.cpp:351: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d93b02 11. /build/src/Functions/IFunction.cpp:177: DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d93698 12. /build/src/Functions/IFunction.cpp:343: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d93aad 13. /build/src/Functions/IFunction.cpp:424: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d94e1b 14. /build/src/Functions/IFunction.cpp:498: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d95c72 15. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3567: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000014034494 16. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3838: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000014019a9e 17. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3980: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000014018e31 18. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:4304: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000014042fa7 19. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5605: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000014013749 20. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000140127f9 21. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000014011fce 22. /build/src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000001406ce8a 23. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000014973b42 24. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000001497268d 25. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000014974d24 26. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001492924b 27. /build/src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88641 28. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 29. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 30. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 31. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 2025.07.28 12:01:26.459024 [ 17252 ] {} TCPHandler: Code: 70. DB::Exception: Value in column Int16 cannot be safely converted into type Int8: In scope SELECT accurateCast(-129, 'Int8'). (CANNOT_CONVERT_TYPE), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000a06a8eb 4. /build/src/Functions/FunctionsConversion.h:1861: COW::immutable_ptr> DB::detail::ConvertImpl, DB::DataTypeNumber<_BitInt(8)>, DB::detail::FunctionCastName, (DB::FormatSettings::DateTimeOverflowBehavior)0>::execute(std::vector> const&, std::vector::shared_ptr const&, unsigned long, DB::detail::BehaviourOnErrorFromString, DB::detail::AccurateConvertStrategyAdditions) @ 0x0000000012e5c5d2 5. /build/src/Functions/FunctionsConversion.h:3582: bool std::function::immutable_ptr> (std::function::vector>&, std::function::shared_ptr const&, DB::ColumnNullable const*, unsigned long)> DB::detail::FunctionCast::createWrapper>(DB::ColumnNullable, DB::DataTypeNumber<_BitInt(8)> const*, bool) const::'lambda'(std::function::shared_ptr, DB::ColumnNullable, COW::immutable_ptr> (std::function::vector>&, std::function::shared_ptr const&, DB::ColumnNullable const*, unsigned long), unsigned long)::operator()(std::function::shared_ptr, DB::ColumnNullable, COW::immutable_ptr> (std::function::vector>&, std::function::shared_ptr const&, DB::ColumnNullable const*, unsigned long), unsigned long) const::'lambda'(DB::DataTypeNumber<_BitInt(8)> const*&)::operator(), std>>('lambda'(DB::DataTypeNumber<_BitInt(8)> const*&)) const @ 0x0000000012e5788f 6. /build/src/Core/callOnTypeIndex.h:260: std::function::immutable_ptr> (std::function::vector>&, std::function::shared_ptr const&, DB::ColumnNullable const*, unsigned long)> DB::detail::FunctionCast::createWrapper>(DB::ColumnNullable, DB::DataTypeNumber<_BitInt(8)> const*, bool) const::'lambda'(std::function::shared_ptr, DB::ColumnNullable, COW::immutable_ptr> (std::function::vector>&, std::function::shared_ptr const&, DB::ColumnNullable const*, unsigned long), unsigned long)::operator()(std::function::shared_ptr, DB::ColumnNullable, COW::immutable_ptr> (std::function::vector>&, std::function::shared_ptr const&, DB::ColumnNullable const*, unsigned long), unsigned long) const @ 0x0000000012e5704a 7. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: COW::immutable_ptr std::__function::__policy_invoker::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)>::__call_impl[abi:se190107]::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)> DB::detail::FunctionCast::createWrapper>(std::shared_ptr const&, DB::DataTypeNumber<_BitInt(8)> 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) @ 0x0000000012e56ecc 8. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000012ddcb1b 9. /build/src/Functions/IFunction.h:57: DB::IExecutableFunction::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000a08134a 10. /build/src/Functions/IFunction.cpp:351: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d93b02 11. /build/src/Functions/IFunction.cpp:177: DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d93698 12. /build/src/Functions/IFunction.cpp:343: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d93aad 13. /build/src/Functions/IFunction.cpp:424: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d94e1b 14. /build/src/Functions/IFunction.cpp:498: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d95c72 15. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3567: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000014034494 16. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3838: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000014019a9e 17. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3980: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000014018e31 18. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:4304: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000014042fa7 19. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5605: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000014013749 20. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000140127f9 21. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000014011fce 22. /build/src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000001406ce8a 23. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000014973b42 24. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000001497268d 25. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000014974d24 26. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001492924b 27. /build/src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88641 28. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 29. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 30. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 31. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 2025.07.28 12:01:26.992305 [ 17252 ] {fadf568b-172c-444a-9108-327d95b23652} executeQuery: Code: 70. DB::Exception: Value in column UInt8 cannot be safely converted into type Int8: In scope SELECT accurateCast(128, 'Int8'). (CANNOT_CONVERT_TYPE) (version 25.3.6.10636.altinitytest (altinity build)) (from [::1]:39342) (comment: 01601_accurate_cast.sql) (query 16, line 17) (in query: SELECT accurateCast(128, 'Int8');), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000a06a8eb 4. /build/src/Functions/FunctionsConversion.h:1861: COW::immutable_ptr> DB::detail::ConvertImpl, DB::DataTypeNumber<_BitInt(8)>, DB::detail::FunctionCastName, (DB::FormatSettings::DateTimeOverflowBehavior)0>::execute(std::vector> const&, std::vector::shared_ptr const&, unsigned long, DB::detail::BehaviourOnErrorFromString, DB::detail::AccurateConvertStrategyAdditions) @ 0x0000000012e58492 5. /build/src/Functions/FunctionsConversion.h:3582: bool std::function::immutable_ptr> (std::function::vector>&, std::function::shared_ptr const&, DB::ColumnNullable const*, unsigned long)> DB::detail::FunctionCast::createWrapper>(DB::ColumnNullable, DB::DataTypeNumber<_BitInt(8)> const*, bool) const::'lambda'(std::function::shared_ptr, DB::ColumnNullable, COW::immutable_ptr> (std::function::vector>&, std::function::shared_ptr const&, DB::ColumnNullable const*, unsigned long), unsigned long)::operator()(std::function::shared_ptr, DB::ColumnNullable, COW::immutable_ptr> (std::function::vector>&, std::function::shared_ptr const&, DB::ColumnNullable const*, unsigned long), unsigned long) const::'lambda'(DB::DataTypeNumber<_BitInt(8)> const*&)::operator(), std>>('lambda'(DB::DataTypeNumber<_BitInt(8)> const*&)) const @ 0x0000000012e5726f 6. /build/src/Core/callOnTypeIndex.h:252: std::function::immutable_ptr> (std::function::vector>&, std::function::shared_ptr const&, DB::ColumnNullable const*, unsigned long)> DB::detail::FunctionCast::createWrapper>(DB::ColumnNullable, DB::DataTypeNumber<_BitInt(8)> const*, bool) const::'lambda'(std::function::shared_ptr, DB::ColumnNullable, COW::immutable_ptr> (std::function::vector>&, std::function::shared_ptr const&, DB::ColumnNullable const*, unsigned long), unsigned long)::operator()(std::function::shared_ptr, DB::ColumnNullable, COW::immutable_ptr> (std::function::vector>&, std::function::shared_ptr const&, DB::ColumnNullable const*, unsigned long), unsigned long) const @ 0x0000000012e56f68 7. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: COW::immutable_ptr std::__function::__policy_invoker::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)>::__call_impl[abi:se190107]::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)> DB::detail::FunctionCast::createWrapper>(std::shared_ptr const&, DB::DataTypeNumber<_BitInt(8)> 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) @ 0x0000000012e56ecc 8. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000012ddcb1b 9. /build/src/Functions/IFunction.h:57: DB::IExecutableFunction::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000a08134a 10. /build/src/Functions/IFunction.cpp:351: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d93b02 11. /build/src/Functions/IFunction.cpp:177: DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d93698 12. /build/src/Functions/IFunction.cpp:343: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d93aad 13. /build/src/Functions/IFunction.cpp:424: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d94e1b 14. /build/src/Functions/IFunction.cpp:498: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d95c72 15. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3567: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000014034494 16. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3838: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000014019a9e 17. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3980: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000014018e31 18. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:4304: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000014042fa7 19. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5605: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000014013749 20. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000140127f9 21. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000014011fce 22. /build/src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000001406ce8a 23. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000014973b42 24. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000001497268d 25. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000014974d24 26. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001492924b 27. /build/src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88641 28. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 29. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 30. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 31. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 2025.07.28 12:01:27.012876 [ 17252 ] {} TCPHandler: Code: 70. DB::Exception: Value in column UInt8 cannot be safely converted into type Int8: In scope SELECT accurateCast(128, 'Int8'). (CANNOT_CONVERT_TYPE), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000a06a8eb 4. /build/src/Functions/FunctionsConversion.h:1861: COW::immutable_ptr> DB::detail::ConvertImpl, DB::DataTypeNumber<_BitInt(8)>, DB::detail::FunctionCastName, (DB::FormatSettings::DateTimeOverflowBehavior)0>::execute(std::vector> const&, std::vector::shared_ptr const&, unsigned long, DB::detail::BehaviourOnErrorFromString, DB::detail::AccurateConvertStrategyAdditions) @ 0x0000000012e58492 5. /build/src/Functions/FunctionsConversion.h:3582: bool std::function::immutable_ptr> (std::function::vector>&, std::function::shared_ptr const&, DB::ColumnNullable const*, unsigned long)> DB::detail::FunctionCast::createWrapper>(DB::ColumnNullable, DB::DataTypeNumber<_BitInt(8)> const*, bool) const::'lambda'(std::function::shared_ptr, DB::ColumnNullable, COW::immutable_ptr> (std::function::vector>&, std::function::shared_ptr const&, DB::ColumnNullable const*, unsigned long), unsigned long)::operator()(std::function::shared_ptr, DB::ColumnNullable, COW::immutable_ptr> (std::function::vector>&, std::function::shared_ptr const&, DB::ColumnNullable const*, unsigned long), unsigned long) const::'lambda'(DB::DataTypeNumber<_BitInt(8)> const*&)::operator(), std>>('lambda'(DB::DataTypeNumber<_BitInt(8)> const*&)) const @ 0x0000000012e5726f 6. /build/src/Core/callOnTypeIndex.h:252: std::function::immutable_ptr> (std::function::vector>&, std::function::shared_ptr const&, DB::ColumnNullable const*, unsigned long)> DB::detail::FunctionCast::createWrapper>(DB::ColumnNullable, DB::DataTypeNumber<_BitInt(8)> const*, bool) const::'lambda'(std::function::shared_ptr, DB::ColumnNullable, COW::immutable_ptr> (std::function::vector>&, std::function::shared_ptr const&, DB::ColumnNullable const*, unsigned long), unsigned long)::operator()(std::function::shared_ptr, DB::ColumnNullable, COW::immutable_ptr> (std::function::vector>&, std::function::shared_ptr const&, DB::ColumnNullable const*, unsigned long), unsigned long) const @ 0x0000000012e56f68 7. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: COW::immutable_ptr std::__function::__policy_invoker::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)>::__call_impl[abi:se190107]::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)> DB::detail::FunctionCast::createWrapper>(std::shared_ptr const&, DB::DataTypeNumber<_BitInt(8)> 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) @ 0x0000000012e56ecc 8. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000012ddcb1b 9. /build/src/Functions/IFunction.h:57: DB::IExecutableFunction::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000a08134a 10. /build/src/Functions/IFunction.cpp:351: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d93b02 11. /build/src/Functions/IFunction.cpp:177: DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d93698 12. /build/src/Functions/IFunction.cpp:343: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d93aad 13. /build/src/Functions/IFunction.cpp:424: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d94e1b 14. /build/src/Functions/IFunction.cpp:498: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d95c72 15. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3567: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000014034494 16. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3838: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000014019a9e 17. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3980: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000014018e31 18. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:4304: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000014042fa7 19. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5605: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000014013749 20. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000140127f9 21. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000014011fce 22. /build/src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000001406ce8a 23. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000014973b42 24. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000001497268d 25. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000014974d24 26. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001492924b 27. /build/src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88641 28. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 29. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 30. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 31. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 2025.07.28 12:01:27.290293 [ 3966 ] {} test_13.rmt2 (7f9b740d-015c-470e-8cc6-8ba33be0dc63): auto DB::StorageReplicatedMergeTree::processQueueEntry(ReplicatedMergeTreeQueue::SelectedEntryPtr)::(anonymous class)::operator()(LogEntryPtr &) const: Code: 86. DB::HTTPException: Received error from remote server http://146b4357c08d:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Ftest%2F01165%2Ftest_13%2Frmt%2Freplicas%2F1&part=20250728_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.6.10636.altinitytest (altinity build)) '. (RECEIVED_ERROR_FROM_REMOTE_IO_SERVER), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.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 const&, int&&, String const&, unsigned long&&, String const&) @ 0x000000000feda8d9 4. /build/src/IO/HTTPCommon.cpp:104: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x000000000feda6e2 5. /build/src/IO/HTTPCommon.cpp:93: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x000000000feda537 6. /build/src/IO/ReadWriteBufferFromHTTP.cpp:277: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x000000001184a4c4 7. /build/src/IO/ReadWriteBufferFromHTTP.cpp:285: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x000000001184a615 8. /build/src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x000000001184ae59 9. /build/src/IO/ReadWriteBufferFromHTTP.cpp:472: void std::__function::__policy_invoker::__call_impl[abi:se190107]>(std::__function::__policy_storage const*) @ 0x000000001184cedd 10. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001184858b 11. /build/src/IO/ReadWriteBufferFromHTTP.cpp:465: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x000000001184bf0b 12. /build/src/IO/ReadBuffer.h:60: DB::ReadBuffer::next() @ 0x000000000a148c7b 13. /build/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) @ 0x0000000011849fb2 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]>&)>&, 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&) @ 0x0000000011841980 15. /build/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) @ 0x000000001621208e 16. /build/src/Storages/StorageReplicatedMergeTree.cpp:5228: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl[abi:se190107] const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000015f9a5fe 17. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000015ed8bfd 18. /build/src/Storages/StorageReplicatedMergeTree.cpp:2514: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x0000000015ec9aab 19. /build/src/Storages/StorageReplicatedMergeTree.cpp:2349: DB::StorageReplicatedMergeTree::executeLogEntry(DB::ReplicatedMergeTreeLogEntry&) @ 0x0000000015eba91b 20. /build/src/Storages/StorageReplicatedMergeTree.cpp:3876: bool std::__function::__policy_invoker&)>::__call_impl[abi:se190107])::$_1, bool (std::shared_ptr&)>>(std::__function::__policy_storage const*, std::shared_ptr&) @ 0x0000000015f9837e 21. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000165d6fc3 22. /build/src/Storages/StorageReplicatedMergeTree.cpp:3872: DB::StorageReplicatedMergeTree::processQueueEntry(std::shared_ptr) @ 0x0000000015efc18a 23. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001624c1b2 24. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000162f9c70 25. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x00000000162fa55a 26. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc6653 27. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000000fccc4c3 28. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc3d92 29. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fcca080 30. ? @ 0x00007fbc6213eac3 31. ? @ 0x00007fbc621d0850 (version 25.3.6.10636.altinitytest (altinity build)) 2025.07.28 12:01:27.361190 [ 17252 ] {17e701c8-ae07-4e6f-bdd8-1d718cceb2ad} executeQuery: Code: 6. DB::Exception: Cannot parse string to type UInt8: In scope SELECT accurateCast('-1', 'UInt8'). (CANNOT_PARSE_TEXT) (version 25.3.6.10636.altinitytest (altinity build)) (from [::1]:39342) (comment: 01601_accurate_cast.sql) (query 17, line 19) (in query: SELECT accurateCast('-1', 'UInt8');), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception> const&>(int, FormatStringHelperImpl> const&>::type>, std::basic_string_view> const&) @ 0x000000000e59abcb 4. /build/src/Functions/FunctionsConversion.h:1033: 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) @ 0x0000000012e0d24c 5. /build/src/Functions/FunctionsConversion.h:1580: 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 @ 0x0000000012e01bf5 6. /build/src/Core/callOnTypeIndex.h:280: 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 @ 0x0000000012e00bec 7. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: COW::immutable_ptr std::__function::__policy_invoker::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)>::__call_impl[abi:se190107]::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) @ 0x0000000012e00a4c 8. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000012ddcb1b 9. /build/src/Functions/IFunction.h:57: DB::IExecutableFunction::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000a08134a 10. /build/src/Functions/IFunction.cpp:351: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d93b02 11. /build/src/Functions/IFunction.cpp:177: DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d93698 12. /build/src/Functions/IFunction.cpp:343: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d93aad 13. /build/src/Functions/IFunction.cpp:424: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d94e1b 14. /build/src/Functions/IFunction.cpp:498: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d95c72 15. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3567: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000014034494 16. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3838: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000014019a9e 17. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3980: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000014018e31 18. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:4304: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000014042fa7 19. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5605: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000014013749 20. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000140127f9 21. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000014011fce 22. /build/src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000001406ce8a 23. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000014973b42 24. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000001497268d 25. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000014974d24 26. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001492924b 27. /build/src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88641 28. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 29. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 30. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 31. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 2025.07.28 12:01:27.365614 [ 17252 ] {} TCPHandler: Code: 6. DB::Exception: Cannot parse string to type UInt8: In scope SELECT accurateCast('-1', 'UInt8'). (CANNOT_PARSE_TEXT), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception> const&>(int, FormatStringHelperImpl> const&>::type>, std::basic_string_view> const&) @ 0x000000000e59abcb 4. /build/src/Functions/FunctionsConversion.h:1033: 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) @ 0x0000000012e0d24c 5. /build/src/Functions/FunctionsConversion.h:1580: 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 @ 0x0000000012e01bf5 6. /build/src/Core/callOnTypeIndex.h:280: 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 @ 0x0000000012e00bec 7. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: COW::immutable_ptr std::__function::__policy_invoker::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)>::__call_impl[abi:se190107]::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) @ 0x0000000012e00a4c 8. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000012ddcb1b 9. /build/src/Functions/IFunction.h:57: DB::IExecutableFunction::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000a08134a 10. /build/src/Functions/IFunction.cpp:351: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d93b02 11. /build/src/Functions/IFunction.cpp:177: DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d93698 12. /build/src/Functions/IFunction.cpp:343: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d93aad 13. /build/src/Functions/IFunction.cpp:424: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d94e1b 14. /build/src/Functions/IFunction.cpp:498: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d95c72 15. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3567: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000014034494 16. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3838: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000014019a9e 17. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3980: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000014018e31 18. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:4304: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000014042fa7 19. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5605: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000014013749 20. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000140127f9 21. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000014011fce 22. /build/src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000001406ce8a 23. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000014973b42 24. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000001497268d 25. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000014974d24 26. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001492924b 27. /build/src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88641 28. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 29. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 30. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 31. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 2025.07.28 12:01:27.727864 [ 3967 ] {} test_13.rmt2 (7f9b740d-015c-470e-8cc6-8ba33be0dc63): auto DB::StorageReplicatedMergeTree::processQueueEntry(ReplicatedMergeTreeQueue::SelectedEntryPtr)::(anonymous class)::operator()(LogEntryPtr &) const: Code: 86. DB::HTTPException: Received error from remote server http://146b4357c08d:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Ftest%2F01165%2Ftest_13%2Frmt%2Freplicas%2F1&part=20250728_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.6.10636.altinitytest (altinity build)) '. (RECEIVED_ERROR_FROM_REMOTE_IO_SERVER), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.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 const&, int&&, String const&, unsigned long&&, String const&) @ 0x000000000feda8d9 4. /build/src/IO/HTTPCommon.cpp:104: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x000000000feda6e2 5. /build/src/IO/HTTPCommon.cpp:93: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x000000000feda537 6. /build/src/IO/ReadWriteBufferFromHTTP.cpp:277: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x000000001184a4c4 7. /build/src/IO/ReadWriteBufferFromHTTP.cpp:285: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x000000001184a615 8. /build/src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x000000001184ae59 9. /build/src/IO/ReadWriteBufferFromHTTP.cpp:472: void std::__function::__policy_invoker::__call_impl[abi:se190107]>(std::__function::__policy_storage const*) @ 0x000000001184cedd 10. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001184858b 11. /build/src/IO/ReadWriteBufferFromHTTP.cpp:465: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x000000001184bf0b 12. /build/src/IO/ReadBuffer.h:60: DB::ReadBuffer::next() @ 0x000000000a148c7b 13. /build/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) @ 0x0000000011849fb2 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]>&)>&, 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&) @ 0x0000000011841980 15. /build/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) @ 0x000000001621208e 16. /build/src/Storages/StorageReplicatedMergeTree.cpp:5228: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl[abi:se190107] const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000015f9a5fe 17. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000015ed8bfd 18. /build/src/Storages/StorageReplicatedMergeTree.cpp:2514: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x0000000015ec9aab 19. /build/src/Storages/StorageReplicatedMergeTree.cpp:2349: DB::StorageReplicatedMergeTree::executeLogEntry(DB::ReplicatedMergeTreeLogEntry&) @ 0x0000000015eba91b 20. /build/src/Storages/StorageReplicatedMergeTree.cpp:3876: bool std::__function::__policy_invoker&)>::__call_impl[abi:se190107])::$_1, bool (std::shared_ptr&)>>(std::__function::__policy_storage const*, std::shared_ptr&) @ 0x0000000015f9837e 21. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000165d6fc3 22. /build/src/Storages/StorageReplicatedMergeTree.cpp:3872: DB::StorageReplicatedMergeTree::processQueueEntry(std::shared_ptr) @ 0x0000000015efc18a 23. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001624c1b2 24. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000162f9c70 25. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x00000000162fa55a 26. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc6653 27. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000000fccc4c3 28. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc3d92 29. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fcca080 30. ? @ 0x00007fbc6213eac3 31. ? @ 0x00007fbc621d0850 (version 25.3.6.10636.altinitytest (altinity build)) 2025.07.28 12:01:27.748536 [ 17252 ] {a4d05f73-0cd0-4281-a685-78c4a6103dec} executeQuery: Code: 6. DB::Exception: Cannot parse string to type UInt8: In scope SELECT accurateCast('257', 'UInt8'). (CANNOT_PARSE_TEXT) (version 25.3.6.10636.altinitytest (altinity build)) (from [::1]:39342) (comment: 01601_accurate_cast.sql) (query 19, line 21) (in query: SELECT accurateCast('257', 'UInt8');), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception> const&>(int, FormatStringHelperImpl> const&>::type>, std::basic_string_view> const&) @ 0x000000000e59abcb 4. /build/src/Functions/FunctionsConversion.h:1033: 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) @ 0x0000000012e0d24c 5. /build/src/Functions/FunctionsConversion.h:1580: 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 @ 0x0000000012e01bf5 6. /build/src/Core/callOnTypeIndex.h:280: 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 @ 0x0000000012e00bec 7. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: COW::immutable_ptr std::__function::__policy_invoker::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)>::__call_impl[abi:se190107]::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) @ 0x0000000012e00a4c 8. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000012ddcb1b 9. /build/src/Functions/IFunction.h:57: DB::IExecutableFunction::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000a08134a 10. /build/src/Functions/IFunction.cpp:351: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d93b02 11. /build/src/Functions/IFunction.cpp:177: DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d93698 12. /build/src/Functions/IFunction.cpp:343: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d93aad 13. /build/src/Functions/IFunction.cpp:424: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d94e1b 14. /build/src/Functions/IFunction.cpp:498: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d95c72 15. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3567: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000014034494 16. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3838: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000014019a9e 17. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3980: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000014018e31 18. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:4304: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000014042fa7 19. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5605: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000014013749 20. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000140127f9 21. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000014011fce 22. /build/src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000001406ce8a 23. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000014973b42 24. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000001497268d 25. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000014974d24 26. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001492924b 27. /build/src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88641 28. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 29. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 30. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 31. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 2025.07.28 12:01:27.756535 [ 17252 ] {} TCPHandler: Code: 6. DB::Exception: Cannot parse string to type UInt8: In scope SELECT accurateCast('257', 'UInt8'). (CANNOT_PARSE_TEXT), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception> const&>(int, FormatStringHelperImpl> const&>::type>, std::basic_string_view> const&) @ 0x000000000e59abcb 4. /build/src/Functions/FunctionsConversion.h:1033: 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) @ 0x0000000012e0d24c 5. /build/src/Functions/FunctionsConversion.h:1580: 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 @ 0x0000000012e01bf5 6. /build/src/Core/callOnTypeIndex.h:280: 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 @ 0x0000000012e00bec 7. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: COW::immutable_ptr std::__function::__policy_invoker::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)>::__call_impl[abi:se190107]::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) @ 0x0000000012e00a4c 8. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000012ddcb1b 9. /build/src/Functions/IFunction.h:57: DB::IExecutableFunction::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000a08134a 10. /build/src/Functions/IFunction.cpp:351: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d93b02 11. /build/src/Functions/IFunction.cpp:177: DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d93698 12. /build/src/Functions/IFunction.cpp:343: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d93aad 13. /build/src/Functions/IFunction.cpp:424: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d94e1b 14. /build/src/Functions/IFunction.cpp:498: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d95c72 15. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3567: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000014034494 16. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3838: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000014019a9e 17. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3980: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000014018e31 18. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:4304: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000014042fa7 19. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5605: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000014013749 20. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000140127f9 21. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000014011fce 22. /build/src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000001406ce8a 23. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000014973b42 24. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000001497268d 25. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000014974d24 26. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001492924b 27. /build/src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88641 28. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 29. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 30. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 31. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 2025.07.28 12:01:27.928248 [ 3968 ] {} test_13.rmt2 (7f9b740d-015c-470e-8cc6-8ba33be0dc63): auto DB::StorageReplicatedMergeTree::processQueueEntry(ReplicatedMergeTreeQueue::SelectedEntryPtr)::(anonymous class)::operator()(LogEntryPtr &) const: Code: 86. DB::HTTPException: Received error from remote server http://146b4357c08d:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Ftest%2F01165%2Ftest_13%2Frmt%2Freplicas%2F1&part=20250728_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.6.10636.altinitytest (altinity build)) '. (RECEIVED_ERROR_FROM_REMOTE_IO_SERVER), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.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 const&, int&&, String const&, unsigned long&&, String const&) @ 0x000000000feda8d9 4. /build/src/IO/HTTPCommon.cpp:104: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x000000000feda6e2 5. /build/src/IO/HTTPCommon.cpp:93: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x000000000feda537 6. /build/src/IO/ReadWriteBufferFromHTTP.cpp:277: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x000000001184a4c4 7. /build/src/IO/ReadWriteBufferFromHTTP.cpp:285: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x000000001184a615 8. /build/src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x000000001184ae59 9. /build/src/IO/ReadWriteBufferFromHTTP.cpp:472: void std::__function::__policy_invoker::__call_impl[abi:se190107]>(std::__function::__policy_storage const*) @ 0x000000001184cedd 10. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001184858b 11. /build/src/IO/ReadWriteBufferFromHTTP.cpp:465: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x000000001184bf0b 12. /build/src/IO/ReadBuffer.h:60: DB::ReadBuffer::next() @ 0x000000000a148c7b 13. /build/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) @ 0x0000000011849fb2 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]>&)>&, 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&) @ 0x0000000011841980 15. /build/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) @ 0x000000001621208e 16. /build/src/Storages/StorageReplicatedMergeTree.cpp:5228: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl[abi:se190107] const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000015f9a5fe 17. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000015ed8bfd 18. /build/src/Storages/StorageReplicatedMergeTree.cpp:2514: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x0000000015ec9aab 19. /build/src/Storages/StorageReplicatedMergeTree.cpp:2349: DB::StorageReplicatedMergeTree::executeLogEntry(DB::ReplicatedMergeTreeLogEntry&) @ 0x0000000015eba91b 20. /build/src/Storages/StorageReplicatedMergeTree.cpp:3876: bool std::__function::__policy_invoker&)>::__call_impl[abi:se190107])::$_1, bool (std::shared_ptr&)>>(std::__function::__policy_storage const*, std::shared_ptr&) @ 0x0000000015f9837e 21. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000165d6fc3 22. /build/src/Storages/StorageReplicatedMergeTree.cpp:3872: DB::StorageReplicatedMergeTree::processQueueEntry(std::shared_ptr) @ 0x0000000015efc18a 23. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001624c1b2 24. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000162f9c70 25. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x00000000162fa55a 26. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc6653 27. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000000fccc4c3 28. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc3d92 29. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fcca080 30. ? @ 0x00007fbc6213eac3 31. ? @ 0x00007fbc621d0850 (version 25.3.6.10636.altinitytest (altinity build)) 2025.07.28 12:01:27.954025 [ 17252 ] {43e19b48-c879-4cd8-8d81-08dd4851b58e} executeQuery: Code: 6. DB::Exception: Cannot parse string to type UInt16: In scope SELECT accurateCast('-1', 'UInt16'). (CANNOT_PARSE_TEXT) (version 25.3.6.10636.altinitytest (altinity build)) (from [::1]:39342) (comment: 01601_accurate_cast.sql) (query 20, line 22) (in query: SELECT accurateCast('-1', 'UInt16');), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception> const&>(int, FormatStringHelperImpl> const&>::type>, std::basic_string_view> const&) @ 0x000000000e59abcb 4. /build/src/Functions/FunctionsConversion.h:1033: 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) @ 0x0000000012e1af64 5. /build/src/Functions/FunctionsConversion.h:1580: 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 @ 0x0000000012e10a95 6. /build/src/Core/callOnTypeIndex.h:280: 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 @ 0x0000000012e0fb6c 7. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: COW::immutable_ptr std::__function::__policy_invoker::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)>::__call_impl[abi:se190107]::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) @ 0x0000000012e0f9cc 8. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000012ddcb1b 9. /build/src/Functions/IFunction.h:57: DB::IExecutableFunction::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000a08134a 10. /build/src/Functions/IFunction.cpp:351: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d93b02 11. /build/src/Functions/IFunction.cpp:177: DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d93698 12. /build/src/Functions/IFunction.cpp:343: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d93aad 13. /build/src/Functions/IFunction.cpp:424: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d94e1b 14. /build/src/Functions/IFunction.cpp:498: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d95c72 15. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3567: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000014034494 16. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3838: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000014019a9e 17. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3980: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000014018e31 18. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:4304: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000014042fa7 19. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5605: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000014013749 20. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000140127f9 21. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000014011fce 22. /build/src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000001406ce8a 23. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000014973b42 24. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000001497268d 25. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000014974d24 26. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001492924b 27. /build/src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88641 28. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 29. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 30. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 31. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 2025.07.28 12:01:27.957208 [ 17252 ] {} TCPHandler: Code: 6. DB::Exception: Cannot parse string to type UInt16: In scope SELECT accurateCast('-1', 'UInt16'). (CANNOT_PARSE_TEXT), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception> const&>(int, FormatStringHelperImpl> const&>::type>, std::basic_string_view> const&) @ 0x000000000e59abcb 4. /build/src/Functions/FunctionsConversion.h:1033: 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) @ 0x0000000012e1af64 5. /build/src/Functions/FunctionsConversion.h:1580: 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 @ 0x0000000012e10a95 6. /build/src/Core/callOnTypeIndex.h:280: 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 @ 0x0000000012e0fb6c 7. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: COW::immutable_ptr std::__function::__policy_invoker::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)>::__call_impl[abi:se190107]::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) @ 0x0000000012e0f9cc 8. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000012ddcb1b 9. /build/src/Functions/IFunction.h:57: DB::IExecutableFunction::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000a08134a 10. /build/src/Functions/IFunction.cpp:351: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d93b02 11. /build/src/Functions/IFunction.cpp:177: DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d93698 12. /build/src/Functions/IFunction.cpp:343: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d93aad 13. /build/src/Functions/IFunction.cpp:424: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d94e1b 14. /build/src/Functions/IFunction.cpp:498: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d95c72 15. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3567: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000014034494 16. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3838: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000014019a9e 17. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3980: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000014018e31 18. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:4304: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000014042fa7 19. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5605: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000014013749 20. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000140127f9 21. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000014011fce 22. /build/src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000001406ce8a 23. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000014973b42 24. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000001497268d 25. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000014974d24 26. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001492924b 27. /build/src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88641 28. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 29. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 30. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 31. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 2025.07.28 12:01:28.184293 [ 17252 ] {649202bd-ba50-4f0c-9ff3-127f4d70cfeb} executeQuery: Code: 6. DB::Exception: Cannot parse string to type UInt16: In scope SELECT accurateCast('65536', 'UInt16'). (CANNOT_PARSE_TEXT) (version 25.3.6.10636.altinitytest (altinity build)) (from [::1]:39342) (comment: 01601_accurate_cast.sql) (query 22, line 24) (in query: SELECT accurateCast('65536', 'UInt16');), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception> const&>(int, FormatStringHelperImpl> const&>::type>, std::basic_string_view> const&) @ 0x000000000e59abcb 4. /build/src/Functions/FunctionsConversion.h:1033: 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) @ 0x0000000012e1af64 5. /build/src/Functions/FunctionsConversion.h:1580: 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 @ 0x0000000012e10a95 6. /build/src/Core/callOnTypeIndex.h:280: 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 @ 0x0000000012e0fb6c 7. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: COW::immutable_ptr std::__function::__policy_invoker::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)>::__call_impl[abi:se190107]::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) @ 0x0000000012e0f9cc 8. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000012ddcb1b 9. /build/src/Functions/IFunction.h:57: DB::IExecutableFunction::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000a08134a 10. /build/src/Functions/IFunction.cpp:351: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d93b02 11. /build/src/Functions/IFunction.cpp:177: DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d93698 12. /build/src/Functions/IFunction.cpp:343: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d93aad 13. /build/src/Functions/IFunction.cpp:424: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d94e1b 14. /build/src/Functions/IFunction.cpp:498: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d95c72 15. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3567: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000014034494 16. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3838: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000014019a9e 17. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3980: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000014018e31 18. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:4304: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000014042fa7 19. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5605: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000014013749 20. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000140127f9 21. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000014011fce 22. /build/src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000001406ce8a 23. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000014973b42 24. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000001497268d 25. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000014974d24 26. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001492924b 27. /build/src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88641 28. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 29. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 30. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 31. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 2025.07.28 12:01:28.209348 [ 17252 ] {} TCPHandler: Code: 6. DB::Exception: Cannot parse string to type UInt16: In scope SELECT accurateCast('65536', 'UInt16'). (CANNOT_PARSE_TEXT), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception> const&>(int, FormatStringHelperImpl> const&>::type>, std::basic_string_view> const&) @ 0x000000000e59abcb 4. /build/src/Functions/FunctionsConversion.h:1033: 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) @ 0x0000000012e1af64 5. /build/src/Functions/FunctionsConversion.h:1580: 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 @ 0x0000000012e10a95 6. /build/src/Core/callOnTypeIndex.h:280: 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 @ 0x0000000012e0fb6c 7. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: COW::immutable_ptr std::__function::__policy_invoker::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)>::__call_impl[abi:se190107]::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) @ 0x0000000012e0f9cc 8. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000012ddcb1b 9. /build/src/Functions/IFunction.h:57: DB::IExecutableFunction::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000a08134a 10. /build/src/Functions/IFunction.cpp:351: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d93b02 11. /build/src/Functions/IFunction.cpp:177: DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d93698 12. /build/src/Functions/IFunction.cpp:343: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d93aad 13. /build/src/Functions/IFunction.cpp:424: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d94e1b 14. /build/src/Functions/IFunction.cpp:498: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d95c72 15. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3567: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000014034494 16. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3838: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000014019a9e 17. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3980: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000014018e31 18. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:4304: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000014042fa7 19. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5605: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000014013749 20. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000140127f9 21. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000014011fce 22. /build/src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000001406ce8a 23. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000014973b42 24. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000001497268d 25. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000014974d24 26. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001492924b 27. /build/src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88641 28. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 29. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 30. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 31. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 2025.07.28 12:01:28.451278 [ 17252 ] {a11b0c6d-e0e2-464f-9643-ecb6ea103c28} executeQuery: Code: 6. DB::Exception: Cannot parse string to type UInt32: In scope SELECT accurateCast('-1', 'UInt32'). (CANNOT_PARSE_TEXT) (version 25.3.6.10636.altinitytest (altinity build)) (from [::1]:39342) (comment: 01601_accurate_cast.sql) (query 23, line 25) (in query: SELECT accurateCast('-1', 'UInt32');), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception> const&>(int, FormatStringHelperImpl> const&>::type>, std::basic_string_view> const&) @ 0x000000000e59abcb 4. /build/src/Functions/FunctionsConversion.h:1033: 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) @ 0x0000000012e2868d 5. /build/src/Functions/FunctionsConversion.h:1580: 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 @ 0x0000000012e1e355 6. /build/src/Core/callOnTypeIndex.h:280: 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 @ 0x0000000012e1d42c 7. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: COW::immutable_ptr std::__function::__policy_invoker::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)>::__call_impl[abi:se190107]::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) @ 0x0000000012e1d28c 8. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000012ddcb1b 9. /build/src/Functions/IFunction.h:57: DB::IExecutableFunction::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000a08134a 10. /build/src/Functions/IFunction.cpp:351: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d93b02 11. /build/src/Functions/IFunction.cpp:177: DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d93698 12. /build/src/Functions/IFunction.cpp:343: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d93aad 13. /build/src/Functions/IFunction.cpp:424: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d94e1b 14. /build/src/Functions/IFunction.cpp:498: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d95c72 15. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3567: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000014034494 16. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3838: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000014019a9e 17. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3980: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000014018e31 18. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:4304: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000014042fa7 19. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5605: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000014013749 20. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000140127f9 21. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000014011fce 22. /build/src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000001406ce8a 23. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000014973b42 24. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000001497268d 25. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000014974d24 26. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001492924b 27. /build/src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88641 28. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 29. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 30. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 31. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 2025.07.28 12:01:28.462910 [ 17252 ] {} TCPHandler: Code: 6. DB::Exception: Cannot parse string to type UInt32: In scope SELECT accurateCast('-1', 'UInt32'). (CANNOT_PARSE_TEXT), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception> const&>(int, FormatStringHelperImpl> const&>::type>, std::basic_string_view> const&) @ 0x000000000e59abcb 4. /build/src/Functions/FunctionsConversion.h:1033: 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) @ 0x0000000012e2868d 5. /build/src/Functions/FunctionsConversion.h:1580: 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 @ 0x0000000012e1e355 6. /build/src/Core/callOnTypeIndex.h:280: 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 @ 0x0000000012e1d42c 7. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: COW::immutable_ptr std::__function::__policy_invoker::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)>::__call_impl[abi:se190107]::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) @ 0x0000000012e1d28c 8. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000012ddcb1b 9. /build/src/Functions/IFunction.h:57: DB::IExecutableFunction::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000a08134a 10. /build/src/Functions/IFunction.cpp:351: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d93b02 11. /build/src/Functions/IFunction.cpp:177: DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d93698 12. /build/src/Functions/IFunction.cpp:343: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d93aad 13. /build/src/Functions/IFunction.cpp:424: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d94e1b 14. /build/src/Functions/IFunction.cpp:498: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d95c72 15. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3567: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000014034494 16. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3838: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000014019a9e 17. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3980: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000014018e31 18. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:4304: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000014042fa7 19. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5605: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000014013749 20. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000140127f9 21. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000014011fce 22. /build/src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000001406ce8a 23. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000014973b42 24. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000001497268d 25. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000014974d24 26. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001492924b 27. /build/src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88641 28. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 29. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 30. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 31. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 2025.07.28 12:01:28.539490 [ 3970 ] {} test_13.rmt2 (7f9b740d-015c-470e-8cc6-8ba33be0dc63): auto DB::StorageReplicatedMergeTree::processQueueEntry(ReplicatedMergeTreeQueue::SelectedEntryPtr)::(anonymous class)::operator()(LogEntryPtr &) const: Code: 86. DB::HTTPException: Received error from remote server http://146b4357c08d:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Ftest%2F01165%2Ftest_13%2Frmt%2Freplicas%2F1&part=20250728_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.6.10636.altinitytest (altinity build)) '. (RECEIVED_ERROR_FROM_REMOTE_IO_SERVER), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.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 const&, int&&, String const&, unsigned long&&, String const&) @ 0x000000000feda8d9 4. /build/src/IO/HTTPCommon.cpp:104: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x000000000feda6e2 5. /build/src/IO/HTTPCommon.cpp:93: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x000000000feda537 6. /build/src/IO/ReadWriteBufferFromHTTP.cpp:277: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x000000001184a4c4 7. /build/src/IO/ReadWriteBufferFromHTTP.cpp:285: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x000000001184a615 8. /build/src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x000000001184ae59 9. /build/src/IO/ReadWriteBufferFromHTTP.cpp:472: void std::__function::__policy_invoker::__call_impl[abi:se190107]>(std::__function::__policy_storage const*) @ 0x000000001184cedd 10. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001184858b 11. /build/src/IO/ReadWriteBufferFromHTTP.cpp:465: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x000000001184bf0b 12. /build/src/IO/ReadBuffer.h:60: DB::ReadBuffer::next() @ 0x000000000a148c7b 13. /build/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) @ 0x0000000011849fb2 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]>&)>&, 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&) @ 0x0000000011841980 15. /build/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) @ 0x000000001621208e 16. /build/src/Storages/StorageReplicatedMergeTree.cpp:5228: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl[abi:se190107] const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000015f9a5fe 17. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000015ed8bfd 18. /build/src/Storages/StorageReplicatedMergeTree.cpp:2514: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x0000000015ec9aab 19. /build/src/Storages/StorageReplicatedMergeTree.cpp:2349: DB::StorageReplicatedMergeTree::executeLogEntry(DB::ReplicatedMergeTreeLogEntry&) @ 0x0000000015eba91b 20. /build/src/Storages/StorageReplicatedMergeTree.cpp:3876: bool std::__function::__policy_invoker&)>::__call_impl[abi:se190107])::$_1, bool (std::shared_ptr&)>>(std::__function::__policy_storage const*, std::shared_ptr&) @ 0x0000000015f9837e 21. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000165d6fc3 22. /build/src/Storages/StorageReplicatedMergeTree.cpp:3872: DB::StorageReplicatedMergeTree::processQueueEntry(std::shared_ptr) @ 0x0000000015efc18a 23. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001624c1b2 24. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000162f9c70 25. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x00000000162fa55a 26. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc6653 27. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000000fccc4c3 28. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc3d92 29. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fcca080 30. ? @ 0x00007fbc6213eac3 31. ? @ 0x00007fbc621d0850 (version 25.3.6.10636.altinitytest (altinity build)) 2025.07.28 12:01:28.757140 [ 17252 ] {3cb1ea86-7968-499c-abc5-b7013b4b2028} executeQuery: Code: 6. DB::Exception: Cannot parse string to type UInt32: In scope SELECT accurateCast('4294967296', 'UInt32'). (CANNOT_PARSE_TEXT) (version 25.3.6.10636.altinitytest (altinity build)) (from [::1]:39342) (comment: 01601_accurate_cast.sql) (query 25, line 27) (in query: SELECT accurateCast('4294967296', 'UInt32');), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception> const&>(int, FormatStringHelperImpl> const&>::type>, std::basic_string_view> const&) @ 0x000000000e59abcb 4. /build/src/Functions/FunctionsConversion.h:1033: 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) @ 0x0000000012e2868d 5. /build/src/Functions/FunctionsConversion.h:1580: 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 @ 0x0000000012e1e355 6. /build/src/Core/callOnTypeIndex.h:280: 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 @ 0x0000000012e1d42c 7. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: COW::immutable_ptr std::__function::__policy_invoker::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)>::__call_impl[abi:se190107]::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) @ 0x0000000012e1d28c 8. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000012ddcb1b 9. /build/src/Functions/IFunction.h:57: DB::IExecutableFunction::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000a08134a 10. /build/src/Functions/IFunction.cpp:351: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d93b02 11. /build/src/Functions/IFunction.cpp:177: DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d93698 12. /build/src/Functions/IFunction.cpp:343: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d93aad 13. /build/src/Functions/IFunction.cpp:424: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d94e1b 14. /build/src/Functions/IFunction.cpp:498: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d95c72 15. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3567: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000014034494 16. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3838: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000014019a9e 17. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3980: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000014018e31 18. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:4304: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000014042fa7 19. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5605: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000014013749 20. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000140127f9 21. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000014011fce 22. /build/src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000001406ce8a 23. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000014973b42 24. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000001497268d 25. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000014974d24 26. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001492924b 27. /build/src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88641 28. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 29. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 30. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 31. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 2025.07.28 12:01:28.763796 [ 17252 ] {} TCPHandler: Code: 6. DB::Exception: Cannot parse string to type UInt32: In scope SELECT accurateCast('4294967296', 'UInt32'). (CANNOT_PARSE_TEXT), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception> const&>(int, FormatStringHelperImpl> const&>::type>, std::basic_string_view> const&) @ 0x000000000e59abcb 4. /build/src/Functions/FunctionsConversion.h:1033: 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) @ 0x0000000012e2868d 5. /build/src/Functions/FunctionsConversion.h:1580: 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 @ 0x0000000012e1e355 6. /build/src/Core/callOnTypeIndex.h:280: 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 @ 0x0000000012e1d42c 7. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: COW::immutable_ptr std::__function::__policy_invoker::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)>::__call_impl[abi:se190107]::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) @ 0x0000000012e1d28c 8. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000012ddcb1b 9. /build/src/Functions/IFunction.h:57: DB::IExecutableFunction::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000a08134a 10. /build/src/Functions/IFunction.cpp:351: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d93b02 11. /build/src/Functions/IFunction.cpp:177: DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d93698 12. /build/src/Functions/IFunction.cpp:343: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d93aad 13. /build/src/Functions/IFunction.cpp:424: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d94e1b 14. /build/src/Functions/IFunction.cpp:498: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d95c72 15. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3567: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000014034494 16. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3838: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000014019a9e 17. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3980: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000014018e31 18. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:4304: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000014042fa7 19. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5605: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000014013749 20. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000140127f9 21. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000014011fce 22. /build/src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000001406ce8a 23. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000014973b42 24. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000001497268d 25. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000014974d24 26. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001492924b 27. /build/src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88641 28. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 29. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 30. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 31. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 2025.07.28 12:01:28.955367 [ 17252 ] {5874e237-7718-4be8-ab38-fc497852b2bb} executeQuery: Code: 6. DB::Exception: Cannot parse string to type UInt64: In scope SELECT accurateCast('-1', 'UInt64'). (CANNOT_PARSE_TEXT) (version 25.3.6.10636.altinitytest (altinity build)) (from [::1]:39342) (comment: 01601_accurate_cast.sql) (query 26, line 28) (in query: SELECT accurateCast('-1', 'UInt64');), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception> const&>(int, FormatStringHelperImpl> const&>::type>, std::basic_string_view> const&) @ 0x000000000e59abcb 4. /build/src/Functions/FunctionsConversion.h:1033: 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) @ 0x0000000012e35fed 5. /build/src/Functions/FunctionsConversion.h:1580: 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 @ 0x0000000012e2ba75 6. /build/src/Core/callOnTypeIndex.h:280: 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 @ 0x0000000012e2ab4c 7. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: COW::immutable_ptr std::__function::__policy_invoker::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)>::__call_impl[abi:se190107]::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) @ 0x0000000012e2a9ac 8. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000012ddcb1b 9. /build/src/Functions/IFunction.h:57: DB::IExecutableFunction::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000a08134a 10. /build/src/Functions/IFunction.cpp:351: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d93b02 11. /build/src/Functions/IFunction.cpp:177: DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d93698 12. /build/src/Functions/IFunction.cpp:343: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d93aad 13. /build/src/Functions/IFunction.cpp:424: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d94e1b 14. /build/src/Functions/IFunction.cpp:498: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d95c72 15. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3567: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000014034494 16. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3838: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000014019a9e 17. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3980: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000014018e31 18. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:4304: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000014042fa7 19. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5605: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000014013749 20. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000140127f9 21. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000014011fce 22. /build/src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000001406ce8a 23. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000014973b42 24. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000001497268d 25. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000014974d24 26. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001492924b 27. /build/src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88641 28. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 29. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 30. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 31. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 2025.07.28 12:01:29.022368 [ 17252 ] {} TCPHandler: Code: 6. DB::Exception: Cannot parse string to type UInt64: In scope SELECT accurateCast('-1', 'UInt64'). (CANNOT_PARSE_TEXT), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception> const&>(int, FormatStringHelperImpl> const&>::type>, std::basic_string_view> const&) @ 0x000000000e59abcb 4. /build/src/Functions/FunctionsConversion.h:1033: 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) @ 0x0000000012e35fed 5. /build/src/Functions/FunctionsConversion.h:1580: 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 @ 0x0000000012e2ba75 6. /build/src/Core/callOnTypeIndex.h:280: 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 @ 0x0000000012e2ab4c 7. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: COW::immutable_ptr std::__function::__policy_invoker::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)>::__call_impl[abi:se190107]::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) @ 0x0000000012e2a9ac 8. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000012ddcb1b 9. /build/src/Functions/IFunction.h:57: DB::IExecutableFunction::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000a08134a 10. /build/src/Functions/IFunction.cpp:351: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d93b02 11. /build/src/Functions/IFunction.cpp:177: DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d93698 12. /build/src/Functions/IFunction.cpp:343: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d93aad 13. /build/src/Functions/IFunction.cpp:424: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d94e1b 14. /build/src/Functions/IFunction.cpp:498: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d95c72 15. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3567: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000014034494 16. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3838: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000014019a9e 17. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3980: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000014018e31 18. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:4304: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000014042fa7 19. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5605: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000014013749 20. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000140127f9 21. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000014011fce 22. /build/src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000001406ce8a 23. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000014973b42 24. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000001497268d 25. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000014974d24 26. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001492924b 27. /build/src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88641 28. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 29. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 30. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 31. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 2025.07.28 12:01:29.270508 [ 3977 ] {} test_13.rmt2 (7f9b740d-015c-470e-8cc6-8ba33be0dc63): auto DB::StorageReplicatedMergeTree::processQueueEntry(ReplicatedMergeTreeQueue::SelectedEntryPtr)::(anonymous class)::operator()(LogEntryPtr &) const: Code: 86. DB::HTTPException: Received error from remote server http://146b4357c08d:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Ftest%2F01165%2Ftest_13%2Frmt%2Freplicas%2F1&part=20250728_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.6.10636.altinitytest (altinity build)) '. (RECEIVED_ERROR_FROM_REMOTE_IO_SERVER), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.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 const&, int&&, String const&, unsigned long&&, String const&) @ 0x000000000feda8d9 4. /build/src/IO/HTTPCommon.cpp:104: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x000000000feda6e2 5. /build/src/IO/HTTPCommon.cpp:93: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x000000000feda537 6. /build/src/IO/ReadWriteBufferFromHTTP.cpp:277: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x000000001184a4c4 7. /build/src/IO/ReadWriteBufferFromHTTP.cpp:285: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x000000001184a615 8. /build/src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x000000001184ae59 9. /build/src/IO/ReadWriteBufferFromHTTP.cpp:472: void std::__function::__policy_invoker::__call_impl[abi:se190107]>(std::__function::__policy_storage const*) @ 0x000000001184cedd 10. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001184858b 11. /build/src/IO/ReadWriteBufferFromHTTP.cpp:465: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x000000001184bf0b 12. /build/src/IO/ReadBuffer.h:60: DB::ReadBuffer::next() @ 0x000000000a148c7b 13. /build/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) @ 0x0000000011849fb2 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]>&)>&, 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&) @ 0x0000000011841980 15. /build/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) @ 0x000000001621208e 16. /build/src/Storages/StorageReplicatedMergeTree.cpp:5228: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl[abi:se190107] const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000015f9a5fe 17. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000015ed8bfd 18. /build/src/Storages/StorageReplicatedMergeTree.cpp:2514: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x0000000015ec9aab 19. /build/src/Storages/StorageReplicatedMergeTree.cpp:2349: DB::StorageReplicatedMergeTree::executeLogEntry(DB::ReplicatedMergeTreeLogEntry&) @ 0x0000000015eba91b 20. /build/src/Storages/StorageReplicatedMergeTree.cpp:3876: bool std::__function::__policy_invoker&)>::__call_impl[abi:se190107])::$_1, bool (std::shared_ptr&)>>(std::__function::__policy_storage const*, std::shared_ptr&) @ 0x0000000015f9837e 21. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000165d6fc3 22. /build/src/Storages/StorageReplicatedMergeTree.cpp:3872: DB::StorageReplicatedMergeTree::processQueueEntry(std::shared_ptr) @ 0x0000000015efc18a 23. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001624c1b2 24. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000162f9c70 25. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x00000000162fa55a 26. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc6653 27. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000000fccc4c3 28. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc3d92 29. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fcca080 30. ? @ 0x00007fbc6213eac3 31. ? @ 0x00007fbc621d0850 (version 25.3.6.10636.altinitytest (altinity build)) 2025.07.28 12:01:29.368592 [ 17252 ] {5bb748cb-2163-4e5c-be33-570eaa44da2a} executeQuery: Code: 6. DB::Exception: Cannot parse string to type Int8: In scope SELECT accurateCast('-129', 'Int8'). (CANNOT_PARSE_TEXT) (version 25.3.6.10636.altinitytest (altinity build)) (from [::1]:39342) (comment: 01601_accurate_cast.sql) (query 28, line 30) (in query: SELECT accurateCast('-129', 'Int8');), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception> const&>(int, FormatStringHelperImpl> const&>::type>, std::basic_string_view> const&) @ 0x000000000e59abcb 4. /build/src/Functions/FunctionsConversion.h:1033: COW::immutable_ptr> DB::detail::ConvertThroughParsing, DB::detail::FunctionCastName, (DB::detail::ConvertFromStringExceptionMode)0, (DB::detail::ConvertFromStringParsingMode)0>::execute(std::vector> const&, std::vector::shared_ptr const&, unsigned long, DB::detail::AccurateConvertStrategyAdditions) @ 0x0000000012e6245a 5. /build/src/Functions/FunctionsConversion.h:1580: bool std::function::immutable_ptr> (std::function::vector>&, std::function::shared_ptr const&, DB::ColumnNullable const*, unsigned long)> DB::detail::FunctionCast::createWrapper>(DB::ColumnNullable, DB::DataTypeNumber<_BitInt(8)> const*, bool) const::'lambda'(std::function::shared_ptr, DB::ColumnNullable, COW::immutable_ptr> (std::function::vector>&, std::function::shared_ptr const&, DB::ColumnNullable const*, unsigned long), unsigned long)::operator()(std::function::shared_ptr, DB::ColumnNullable, COW::immutable_ptr> (std::function::vector>&, std::function::shared_ptr const&, DB::ColumnNullable const*, unsigned long), unsigned long) const::'lambda'(DB::DataTypeNumber<_BitInt(8)> const*&)::operator()>('lambda'(DB::DataTypeNumber<_BitInt(8)> const*&)) const @ 0x0000000012e57f95 6. /build/src/Core/callOnTypeIndex.h:280: std::function::immutable_ptr> (std::function::vector>&, std::function::shared_ptr const&, DB::ColumnNullable const*, unsigned long)> DB::detail::FunctionCast::createWrapper>(DB::ColumnNullable, DB::DataTypeNumber<_BitInt(8)> const*, bool) const::'lambda'(std::function::shared_ptr, DB::ColumnNullable, COW::immutable_ptr> (std::function::vector>&, std::function::shared_ptr const&, DB::ColumnNullable const*, unsigned long), unsigned long)::operator()(std::function::shared_ptr, DB::ColumnNullable, COW::immutable_ptr> (std::function::vector>&, std::function::shared_ptr const&, DB::ColumnNullable const*, unsigned long), unsigned long) const @ 0x0000000012e5706c 7. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: COW::immutable_ptr std::__function::__policy_invoker::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)>::__call_impl[abi:se190107]::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)> DB::detail::FunctionCast::createWrapper>(std::shared_ptr const&, DB::DataTypeNumber<_BitInt(8)> 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) @ 0x0000000012e56ecc 8. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000012ddcb1b 9. /build/src/Functions/IFunction.h:57: DB::IExecutableFunction::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000a08134a 10. /build/src/Functions/IFunction.cpp:351: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d93b02 11. /build/src/Functions/IFunction.cpp:177: DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d93698 12. /build/src/Functions/IFunction.cpp:343: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d93aad 13. /build/src/Functions/IFunction.cpp:424: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d94e1b 14. /build/src/Functions/IFunction.cpp:498: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d95c72 15. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3567: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000014034494 16. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3838: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000014019a9e 17. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3980: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000014018e31 18. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:4304: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000014042fa7 19. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5605: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000014013749 20. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000140127f9 21. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000014011fce 22. /build/src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000001406ce8a 23. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000014973b42 24. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000001497268d 25. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000014974d24 26. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001492924b 27. /build/src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88641 28. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 29. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 30. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 31. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 2025.07.28 12:01:29.382473 [ 17252 ] {} TCPHandler: Code: 6. DB::Exception: Cannot parse string to type Int8: In scope SELECT accurateCast('-129', 'Int8'). (CANNOT_PARSE_TEXT), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception> const&>(int, FormatStringHelperImpl> const&>::type>, std::basic_string_view> const&) @ 0x000000000e59abcb 4. /build/src/Functions/FunctionsConversion.h:1033: COW::immutable_ptr> DB::detail::ConvertThroughParsing, DB::detail::FunctionCastName, (DB::detail::ConvertFromStringExceptionMode)0, (DB::detail::ConvertFromStringParsingMode)0>::execute(std::vector> const&, std::vector::shared_ptr const&, unsigned long, DB::detail::AccurateConvertStrategyAdditions) @ 0x0000000012e6245a 5. /build/src/Functions/FunctionsConversion.h:1580: bool std::function::immutable_ptr> (std::function::vector>&, std::function::shared_ptr const&, DB::ColumnNullable const*, unsigned long)> DB::detail::FunctionCast::createWrapper>(DB::ColumnNullable, DB::DataTypeNumber<_BitInt(8)> const*, bool) const::'lambda'(std::function::shared_ptr, DB::ColumnNullable, COW::immutable_ptr> (std::function::vector>&, std::function::shared_ptr const&, DB::ColumnNullable const*, unsigned long), unsigned long)::operator()(std::function::shared_ptr, DB::ColumnNullable, COW::immutable_ptr> (std::function::vector>&, std::function::shared_ptr const&, DB::ColumnNullable const*, unsigned long), unsigned long) const::'lambda'(DB::DataTypeNumber<_BitInt(8)> const*&)::operator()>('lambda'(DB::DataTypeNumber<_BitInt(8)> const*&)) const @ 0x0000000012e57f95 6. /build/src/Core/callOnTypeIndex.h:280: std::function::immutable_ptr> (std::function::vector>&, std::function::shared_ptr const&, DB::ColumnNullable const*, unsigned long)> DB::detail::FunctionCast::createWrapper>(DB::ColumnNullable, DB::DataTypeNumber<_BitInt(8)> const*, bool) const::'lambda'(std::function::shared_ptr, DB::ColumnNullable, COW::immutable_ptr> (std::function::vector>&, std::function::shared_ptr const&, DB::ColumnNullable const*, unsigned long), unsigned long)::operator()(std::function::shared_ptr, DB::ColumnNullable, COW::immutable_ptr> (std::function::vector>&, std::function::shared_ptr const&, DB::ColumnNullable const*, unsigned long), unsigned long) const @ 0x0000000012e5706c 7. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: COW::immutable_ptr std::__function::__policy_invoker::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)>::__call_impl[abi:se190107]::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)> DB::detail::FunctionCast::createWrapper>(std::shared_ptr const&, DB::DataTypeNumber<_BitInt(8)> 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) @ 0x0000000012e56ecc 8. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000012ddcb1b 9. /build/src/Functions/IFunction.h:57: DB::IExecutableFunction::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000a08134a 10. /build/src/Functions/IFunction.cpp:351: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d93b02 11. /build/src/Functions/IFunction.cpp:177: DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d93698 12. /build/src/Functions/IFunction.cpp:343: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d93aad 13. /build/src/Functions/IFunction.cpp:424: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d94e1b 14. /build/src/Functions/IFunction.cpp:498: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d95c72 15. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3567: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000014034494 16. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3838: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000014019a9e 17. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3980: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000014018e31 18. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:4304: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000014042fa7 19. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5605: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000014013749 20. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000140127f9 21. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000014011fce 22. /build/src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000001406ce8a 23. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000014973b42 24. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000001497268d 25. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000014974d24 26. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001492924b 27. /build/src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88641 28. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 29. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 30. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 31. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 2025.07.28 12:01:29.616446 [ 17252 ] {796be924-76c5-4a3d-abfa-35ac3dae1f93} executeQuery: Code: 6. DB::Exception: Cannot parse string to type Int8: In scope SELECT accurateCast('128', 'Int8'). (CANNOT_PARSE_TEXT) (version 25.3.6.10636.altinitytest (altinity build)) (from [::1]:39342) (comment: 01601_accurate_cast.sql) (query 30, line 32) (in query: SELECT accurateCast('128', 'Int8');), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception> const&>(int, FormatStringHelperImpl> const&>::type>, std::basic_string_view> const&) @ 0x000000000e59abcb 4. /build/src/Functions/FunctionsConversion.h:1033: COW::immutable_ptr> DB::detail::ConvertThroughParsing, DB::detail::FunctionCastName, (DB::detail::ConvertFromStringExceptionMode)0, (DB::detail::ConvertFromStringParsingMode)0>::execute(std::vector> const&, std::vector::shared_ptr const&, unsigned long, DB::detail::AccurateConvertStrategyAdditions) @ 0x0000000012e6245a 5. /build/src/Functions/FunctionsConversion.h:1580: bool std::function::immutable_ptr> (std::function::vector>&, std::function::shared_ptr const&, DB::ColumnNullable const*, unsigned long)> DB::detail::FunctionCast::createWrapper>(DB::ColumnNullable, DB::DataTypeNumber<_BitInt(8)> const*, bool) const::'lambda'(std::function::shared_ptr, DB::ColumnNullable, COW::immutable_ptr> (std::function::vector>&, std::function::shared_ptr const&, DB::ColumnNullable const*, unsigned long), unsigned long)::operator()(std::function::shared_ptr, DB::ColumnNullable, COW::immutable_ptr> (std::function::vector>&, std::function::shared_ptr const&, DB::ColumnNullable const*, unsigned long), unsigned long) const::'lambda'(DB::DataTypeNumber<_BitInt(8)> const*&)::operator()>('lambda'(DB::DataTypeNumber<_BitInt(8)> const*&)) const @ 0x0000000012e57f95 6. /build/src/Core/callOnTypeIndex.h:280: std::function::immutable_ptr> (std::function::vector>&, std::function::shared_ptr const&, DB::ColumnNullable const*, unsigned long)> DB::detail::FunctionCast::createWrapper>(DB::ColumnNullable, DB::DataTypeNumber<_BitInt(8)> const*, bool) const::'lambda'(std::function::shared_ptr, DB::ColumnNullable, COW::immutable_ptr> (std::function::vector>&, std::function::shared_ptr const&, DB::ColumnNullable const*, unsigned long), unsigned long)::operator()(std::function::shared_ptr, DB::ColumnNullable, COW::immutable_ptr> (std::function::vector>&, std::function::shared_ptr const&, DB::ColumnNullable const*, unsigned long), unsigned long) const @ 0x0000000012e5706c 7. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: COW::immutable_ptr std::__function::__policy_invoker::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)>::__call_impl[abi:se190107]::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)> DB::detail::FunctionCast::createWrapper>(std::shared_ptr const&, DB::DataTypeNumber<_BitInt(8)> 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) @ 0x0000000012e56ecc 8. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000012ddcb1b 9. /build/src/Functions/IFunction.h:57: DB::IExecutableFunction::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000a08134a 10. /build/src/Functions/IFunction.cpp:351: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d93b02 11. /build/src/Functions/IFunction.cpp:177: DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d93698 12. /build/src/Functions/IFunction.cpp:343: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d93aad 13. /build/src/Functions/IFunction.cpp:424: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d94e1b 14. /build/src/Functions/IFunction.cpp:498: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d95c72 15. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3567: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000014034494 16. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3838: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000014019a9e 17. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3980: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000014018e31 18. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:4304: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000014042fa7 19. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5605: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000014013749 20. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000140127f9 21. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000014011fce 22. /build/src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000001406ce8a 23. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000014973b42 24. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000001497268d 25. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000014974d24 26. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001492924b 27. /build/src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88641 28. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 29. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 30. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 31. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 2025.07.28 12:01:29.621405 [ 17252 ] {} TCPHandler: Code: 6. DB::Exception: Cannot parse string to type Int8: In scope SELECT accurateCast('128', 'Int8'). (CANNOT_PARSE_TEXT), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception> const&>(int, FormatStringHelperImpl> const&>::type>, std::basic_string_view> const&) @ 0x000000000e59abcb 4. /build/src/Functions/FunctionsConversion.h:1033: COW::immutable_ptr> DB::detail::ConvertThroughParsing, DB::detail::FunctionCastName, (DB::detail::ConvertFromStringExceptionMode)0, (DB::detail::ConvertFromStringParsingMode)0>::execute(std::vector> const&, std::vector::shared_ptr const&, unsigned long, DB::detail::AccurateConvertStrategyAdditions) @ 0x0000000012e6245a 5. /build/src/Functions/FunctionsConversion.h:1580: bool std::function::immutable_ptr> (std::function::vector>&, std::function::shared_ptr const&, DB::ColumnNullable const*, unsigned long)> DB::detail::FunctionCast::createWrapper>(DB::ColumnNullable, DB::DataTypeNumber<_BitInt(8)> const*, bool) const::'lambda'(std::function::shared_ptr, DB::ColumnNullable, COW::immutable_ptr> (std::function::vector>&, std::function::shared_ptr const&, DB::ColumnNullable const*, unsigned long), unsigned long)::operator()(std::function::shared_ptr, DB::ColumnNullable, COW::immutable_ptr> (std::function::vector>&, std::function::shared_ptr const&, DB::ColumnNullable const*, unsigned long), unsigned long) const::'lambda'(DB::DataTypeNumber<_BitInt(8)> const*&)::operator()>('lambda'(DB::DataTypeNumber<_BitInt(8)> const*&)) const @ 0x0000000012e57f95 6. /build/src/Core/callOnTypeIndex.h:280: std::function::immutable_ptr> (std::function::vector>&, std::function::shared_ptr const&, DB::ColumnNullable const*, unsigned long)> DB::detail::FunctionCast::createWrapper>(DB::ColumnNullable, DB::DataTypeNumber<_BitInt(8)> const*, bool) const::'lambda'(std::function::shared_ptr, DB::ColumnNullable, COW::immutable_ptr> (std::function::vector>&, std::function::shared_ptr const&, DB::ColumnNullable const*, unsigned long), unsigned long)::operator()(std::function::shared_ptr, DB::ColumnNullable, COW::immutable_ptr> (std::function::vector>&, std::function::shared_ptr const&, DB::ColumnNullable const*, unsigned long), unsigned long) const @ 0x0000000012e5706c 7. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: COW::immutable_ptr std::__function::__policy_invoker::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)>::__call_impl[abi:se190107]::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)> DB::detail::FunctionCast::createWrapper>(std::shared_ptr const&, DB::DataTypeNumber<_BitInt(8)> 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) @ 0x0000000012e56ecc 8. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000012ddcb1b 9. /build/src/Functions/IFunction.h:57: DB::IExecutableFunction::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000a08134a 10. /build/src/Functions/IFunction.cpp:351: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d93b02 11. /build/src/Functions/IFunction.cpp:177: DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d93698 12. /build/src/Functions/IFunction.cpp:343: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d93aad 13. /build/src/Functions/IFunction.cpp:424: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d94e1b 14. /build/src/Functions/IFunction.cpp:498: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d95c72 15. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3567: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000014034494 16. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3838: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000014019a9e 17. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3980: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000014018e31 18. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:4304: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000014042fa7 19. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5605: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000014013749 20. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000140127f9 21. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000014011fce 22. /build/src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000001406ce8a 23. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000014973b42 24. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000001497268d 25. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000014974d24 26. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001492924b 27. /build/src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88641 28. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 29. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 30. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 31. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 2025.07.28 12:01:29.751138 [ 3966 ] {} test_13.rmt2 (7f9b740d-015c-470e-8cc6-8ba33be0dc63): auto DB::StorageReplicatedMergeTree::processQueueEntry(ReplicatedMergeTreeQueue::SelectedEntryPtr)::(anonymous class)::operator()(LogEntryPtr &) const: Code: 86. DB::HTTPException: Received error from remote server http://146b4357c08d:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Ftest%2F01165%2Ftest_13%2Frmt%2Freplicas%2F1&part=20250728_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.6.10636.altinitytest (altinity build)) '. (RECEIVED_ERROR_FROM_REMOTE_IO_SERVER), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.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 const&, int&&, String const&, unsigned long&&, String const&) @ 0x000000000feda8d9 4. /build/src/IO/HTTPCommon.cpp:104: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x000000000feda6e2 5. /build/src/IO/HTTPCommon.cpp:93: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x000000000feda537 6. /build/src/IO/ReadWriteBufferFromHTTP.cpp:277: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x000000001184a4c4 7. /build/src/IO/ReadWriteBufferFromHTTP.cpp:285: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x000000001184a615 8. /build/src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x000000001184ae59 9. /build/src/IO/ReadWriteBufferFromHTTP.cpp:472: void std::__function::__policy_invoker::__call_impl[abi:se190107]>(std::__function::__policy_storage const*) @ 0x000000001184cedd 10. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001184858b 11. /build/src/IO/ReadWriteBufferFromHTTP.cpp:465: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x000000001184bf0b 12. /build/src/IO/ReadBuffer.h:60: DB::ReadBuffer::next() @ 0x000000000a148c7b 13. /build/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) @ 0x0000000011849fb2 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]>&)>&, 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&) @ 0x0000000011841980 15. /build/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) @ 0x000000001621208e 16. /build/src/Storages/StorageReplicatedMergeTree.cpp:5228: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl[abi:se190107] const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000015f9a5fe 17. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000015ed8bfd 18. /build/src/Storages/StorageReplicatedMergeTree.cpp:2514: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x0000000015ec9aab 19. /build/src/Storages/StorageReplicatedMergeTree.cpp:2349: DB::StorageReplicatedMergeTree::executeLogEntry(DB::ReplicatedMergeTreeLogEntry&) @ 0x0000000015eba91b 20. /build/src/Storages/StorageReplicatedMergeTree.cpp:3876: bool std::__function::__policy_invoker&)>::__call_impl[abi:se190107])::$_1, bool (std::shared_ptr&)>>(std::__function::__policy_storage const*, std::shared_ptr&) @ 0x0000000015f9837e 21. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000165d6fc3 22. /build/src/Storages/StorageReplicatedMergeTree.cpp:3872: DB::StorageReplicatedMergeTree::processQueueEntry(std::shared_ptr) @ 0x0000000015efc18a 23. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001624c1b2 24. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000162f9c70 25. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x00000000162fa55a 26. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc6653 27. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000000fccc4c3 28. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc3d92 29. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fcca080 30. ? @ 0x00007fbc6213eac3 31. ? @ 0x00007fbc621d0850 (version 25.3.6.10636.altinitytest (altinity build)) 2025.07.28 12:01:29.880862 [ 17252 ] {fa87f565-6f1f-44fe-add5-c06559ea3895} executeQuery: Code: 407. DB::Exception: Decimal convert overflow: 10000000000 is not in range (-2147483648, 2147483647): In scope SELECT accurateCast(10, 'Decimal32(9)'). (DECIMAL_OVERFLOW) (version 25.3.6.10636.altinitytest (altinity build)) (from [::1]:39342) (comment: 01601_accurate_cast.sql) (query 31, line 34) (in query: SELECT accurateCast(10, 'Decimal32(9)');), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/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&&) @ 0x000000000a1011eb 4. /build/src/DataTypes/DataTypesDecimal.cpp:155: void DB::convertDecimalsImpl>, DB::DataTypeDecimal>, void>(T::FieldType const&, unsigned int, unsigned int, T0::FieldType&) @ 0x0000000013c1e6d8 5. /build/src/DataTypes/DataTypesDecimal.cpp:308: T0::FieldType DB::convertToDecimal, DB::DataTypeDecimal>>(T::FieldType const&, unsigned int) @ 0x0000000013c3299f 6. /build/src/Functions/FunctionsConversion.h:1764: 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, DB::detail::AccurateConvertStrategyAdditions) @ 0x0000000012ed53d4 7. /build/src/Functions/FunctionsConversion.h:3762: 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 @ 0x0000000012ed34ff 8. /build/src/Core/callOnTypeIndex.h:252: 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 @ 0x0000000012ed2dd1 9. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: COW::immutable_ptr std::__function::__policy_invoker::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)>::__call_impl[abi:se190107]::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) @ 0x0000000012ed2d2c 10. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000012ddcb1b 11. /build/src/Functions/IFunction.h:57: DB::IExecutableFunction::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000a08134a 12. /build/src/Functions/IFunction.cpp:351: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d93b02 13. /build/src/Functions/IFunction.cpp:177: DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d93698 14. /build/src/Functions/IFunction.cpp:343: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d93aad 15. /build/src/Functions/IFunction.cpp:424: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d94e1b 16. /build/src/Functions/IFunction.cpp:498: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d95c72 17. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3567: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000014034494 18. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3838: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000014019a9e 19. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3980: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000014018e31 20. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:4304: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000014042fa7 21. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5605: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000014013749 22. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000140127f9 23. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000014011fce 24. /build/src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000001406ce8a 25. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000014973b42 26. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000001497268d 27. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000014974d24 28. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001492924b 29. /build/src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88641 30. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 31. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 2025.07.28 12:01:29.884162 [ 17252 ] {} TCPHandler: Code: 407. DB::Exception: Decimal convert overflow: 10000000000 is not in range (-2147483648, 2147483647): In scope SELECT accurateCast(10, 'Decimal32(9)'). (DECIMAL_OVERFLOW), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/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&&) @ 0x000000000a1011eb 4. /build/src/DataTypes/DataTypesDecimal.cpp:155: void DB::convertDecimalsImpl>, DB::DataTypeDecimal>, void>(T::FieldType const&, unsigned int, unsigned int, T0::FieldType&) @ 0x0000000013c1e6d8 5. /build/src/DataTypes/DataTypesDecimal.cpp:308: T0::FieldType DB::convertToDecimal, DB::DataTypeDecimal>>(T::FieldType const&, unsigned int) @ 0x0000000013c3299f 6. /build/src/Functions/FunctionsConversion.h:1764: 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, DB::detail::AccurateConvertStrategyAdditions) @ 0x0000000012ed53d4 7. /build/src/Functions/FunctionsConversion.h:3762: 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 @ 0x0000000012ed34ff 8. /build/src/Core/callOnTypeIndex.h:252: 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 @ 0x0000000012ed2dd1 9. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: COW::immutable_ptr std::__function::__policy_invoker::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)>::__call_impl[abi:se190107]::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) @ 0x0000000012ed2d2c 10. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000012ddcb1b 11. /build/src/Functions/IFunction.h:57: DB::IExecutableFunction::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000a08134a 12. /build/src/Functions/IFunction.cpp:351: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d93b02 13. /build/src/Functions/IFunction.cpp:177: DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d93698 14. /build/src/Functions/IFunction.cpp:343: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d93aad 15. /build/src/Functions/IFunction.cpp:424: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d94e1b 16. /build/src/Functions/IFunction.cpp:498: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d95c72 17. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3567: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000014034494 18. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3838: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000014019a9e 19. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3980: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000014018e31 20. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:4304: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000014042fa7 21. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5605: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000014013749 22. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000140127f9 23. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000014011fce 24. /build/src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000001406ce8a 25. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000014973b42 26. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000001497268d 27. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000014974d24 28. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001492924b 29. /build/src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88641 30. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 31. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 2025.07.28 12:01:29.955631 [ 3974 ] {} test_13.rmt2 (7f9b740d-015c-470e-8cc6-8ba33be0dc63): auto DB::StorageReplicatedMergeTree::processQueueEntry(ReplicatedMergeTreeQueue::SelectedEntryPtr)::(anonymous class)::operator()(LogEntryPtr &) const: Code: 86. DB::HTTPException: Received error from remote server http://146b4357c08d:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Ftest%2F01165%2Ftest_13%2Frmt%2Freplicas%2F1&part=20250728_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.6.10636.altinitytest (altinity build)) '. (RECEIVED_ERROR_FROM_REMOTE_IO_SERVER), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.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 const&, int&&, String const&, unsigned long&&, String const&) @ 0x000000000feda8d9 4. /build/src/IO/HTTPCommon.cpp:104: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x000000000feda6e2 5. /build/src/IO/HTTPCommon.cpp:93: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x000000000feda537 6. /build/src/IO/ReadWriteBufferFromHTTP.cpp:277: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x000000001184a4c4 7. /build/src/IO/ReadWriteBufferFromHTTP.cpp:285: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x000000001184a615 8. /build/src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x000000001184ae59 9. /build/src/IO/ReadWriteBufferFromHTTP.cpp:472: void std::__function::__policy_invoker::__call_impl[abi:se190107]>(std::__function::__policy_storage const*) @ 0x000000001184cedd 10. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001184858b 11. /build/src/IO/ReadWriteBufferFromHTTP.cpp:465: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x000000001184bf0b 12. /build/src/IO/ReadBuffer.h:60: DB::ReadBuffer::next() @ 0x000000000a148c7b 13. /build/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) @ 0x0000000011849fb2 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]>&)>&, 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&) @ 0x0000000011841980 15. /build/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) @ 0x000000001621208e 16. /build/src/Storages/StorageReplicatedMergeTree.cpp:5228: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl[abi:se190107] const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000015f9a5fe 17. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000015ed8bfd 18. /build/src/Storages/StorageReplicatedMergeTree.cpp:2514: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x0000000015ec9aab 19. /build/src/Storages/StorageReplicatedMergeTree.cpp:2349: DB::StorageReplicatedMergeTree::executeLogEntry(DB::ReplicatedMergeTreeLogEntry&) @ 0x0000000015eba91b 20. /build/src/Storages/StorageReplicatedMergeTree.cpp:3876: bool std::__function::__policy_invoker&)>::__call_impl[abi:se190107])::$_1, bool (std::shared_ptr&)>>(std::__function::__policy_storage const*, std::shared_ptr&) @ 0x0000000015f9837e 21. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000165d6fc3 22. /build/src/Storages/StorageReplicatedMergeTree.cpp:3872: DB::StorageReplicatedMergeTree::processQueueEntry(std::shared_ptr) @ 0x0000000015efc18a 23. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001624c1b2 24. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000162f9c70 25. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x00000000162fa55a 26. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc6653 27. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000000fccc4c3 28. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc3d92 29. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fcca080 30. ? @ 0x00007fbc6213eac3 31. ? @ 0x00007fbc621d0850 (version 25.3.6.10636.altinitytest (altinity build)) 2025.07.28 12:01:30.347722 [ 17252 ] {68ada440-a05f-4ebd-91c1-65bfdbe0d3d1} executeQuery: Code: 407. DB::Exception: Decimal convert overflow: -10000000000 is not in range (-2147483648, 2147483647): In scope SELECT accurateCast(-10, 'Decimal32(9)'). (DECIMAL_OVERFLOW) (version 25.3.6.10636.altinitytest (altinity build)) (from [::1]:39342) (comment: 01601_accurate_cast.sql) (query 33, line 36) (in query: SELECT accurateCast(-10, 'Decimal32(9)');), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/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&&) @ 0x000000000a1011eb 4. /build/src/DataTypes/DataTypesDecimal.cpp:155: void DB::convertDecimalsImpl>, DB::DataTypeDecimal>, void>(T::FieldType const&, unsigned int, unsigned int, T0::FieldType&) @ 0x0000000013c1e6d8 5. /build/src/DataTypes/DataTypesDecimal.cpp:308: _ZN2DB16convertToDecimalINS_14DataTypeNumberIDB8_EENS_15DataTypeDecimalINS_7DecimalIiEEEEQaa15is_arithmetic_vINT_9FieldTypeEE17IsDataTypeDecimalIT0_EEENSA_9FieldTypeERKS9_j @ 0x0000000013c32960 6. /build/src/Functions/FunctionsConversion.h:1764: COW::immutable_ptr> DB::detail::ConvertImpl, DB::DataTypeDecimal>, DB::detail::FunctionCastName, (DB::FormatSettings::DateTimeOverflowBehavior)0>::execute(std::vector> const&, std::vector::shared_ptr const&, unsigned long, DB::detail::BehaviourOnErrorFromString, DB::detail::AccurateConvertStrategyAdditions) @ 0x0000000012eda5f4 7. /build/src/Functions/FunctionsConversion.h:3762: 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 @ 0x0000000012ed3d3f 8. /build/src/Core/callOnTypeIndex.h:259: 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 @ 0x0000000012ed303c 9. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: COW::immutable_ptr std::__function::__policy_invoker::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)>::__call_impl[abi:se190107]::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) @ 0x0000000012ed2d2c 10. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000012ddcb1b 11. /build/src/Functions/IFunction.h:57: DB::IExecutableFunction::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000a08134a 12. /build/src/Functions/IFunction.cpp:351: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d93b02 13. /build/src/Functions/IFunction.cpp:177: DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d93698 14. /build/src/Functions/IFunction.cpp:343: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d93aad 15. /build/src/Functions/IFunction.cpp:424: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d94e1b 16. /build/src/Functions/IFunction.cpp:498: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d95c72 17. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3567: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000014034494 18. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3838: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000014019a9e 19. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3980: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000014018e31 20. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:4304: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000014042fa7 21. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5605: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000014013749 22. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000140127f9 23. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000014011fce 24. /build/src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000001406ce8a 25. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000014973b42 26. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000001497268d 27. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000014974d24 28. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001492924b 29. /build/src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88641 30. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 31. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 2025.07.28 12:01:30.370843 [ 17252 ] {} TCPHandler: Code: 407. DB::Exception: Decimal convert overflow: -10000000000 is not in range (-2147483648, 2147483647): In scope SELECT accurateCast(-10, 'Decimal32(9)'). (DECIMAL_OVERFLOW), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/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&&) @ 0x000000000a1011eb 4. /build/src/DataTypes/DataTypesDecimal.cpp:155: void DB::convertDecimalsImpl>, DB::DataTypeDecimal>, void>(T::FieldType const&, unsigned int, unsigned int, T0::FieldType&) @ 0x0000000013c1e6d8 5. /build/src/DataTypes/DataTypesDecimal.cpp:308: _ZN2DB16convertToDecimalINS_14DataTypeNumberIDB8_EENS_15DataTypeDecimalINS_7DecimalIiEEEEQaa15is_arithmetic_vINT_9FieldTypeEE17IsDataTypeDecimalIT0_EEENSA_9FieldTypeERKS9_j @ 0x0000000013c32960 6. /build/src/Functions/FunctionsConversion.h:1764: COW::immutable_ptr> DB::detail::ConvertImpl, DB::DataTypeDecimal>, DB::detail::FunctionCastName, (DB::FormatSettings::DateTimeOverflowBehavior)0>::execute(std::vector> const&, std::vector::shared_ptr const&, unsigned long, DB::detail::BehaviourOnErrorFromString, DB::detail::AccurateConvertStrategyAdditions) @ 0x0000000012eda5f4 7. /build/src/Functions/FunctionsConversion.h:3762: 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 @ 0x0000000012ed3d3f 8. /build/src/Core/callOnTypeIndex.h:259: 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 @ 0x0000000012ed303c 9. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: COW::immutable_ptr std::__function::__policy_invoker::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)>::__call_impl[abi:se190107]::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) @ 0x0000000012ed2d2c 10. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000012ddcb1b 11. /build/src/Functions/IFunction.h:57: DB::IExecutableFunction::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000a08134a 12. /build/src/Functions/IFunction.cpp:351: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d93b02 13. /build/src/Functions/IFunction.cpp:177: DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d93698 14. /build/src/Functions/IFunction.cpp:343: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d93aad 15. /build/src/Functions/IFunction.cpp:424: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d94e1b 16. /build/src/Functions/IFunction.cpp:498: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d95c72 17. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3567: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000014034494 18. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3838: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000014019a9e 19. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3980: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000014018e31 20. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:4304: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000014042fa7 21. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5605: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000014013749 22. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000140127f9 23. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000014011fce 24. /build/src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000001406ce8a 25. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000014973b42 26. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000001497268d 27. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000014974d24 28. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001492924b 29. /build/src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88641 30. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 31. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 2025.07.28 12:01:30.472078 [ 3976 ] {} test_13.rmt2 (7f9b740d-015c-470e-8cc6-8ba33be0dc63): auto DB::StorageReplicatedMergeTree::processQueueEntry(ReplicatedMergeTreeQueue::SelectedEntryPtr)::(anonymous class)::operator()(LogEntryPtr &) const: Code: 86. DB::HTTPException: Received error from remote server http://146b4357c08d:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Ftest%2F01165%2Ftest_13%2Frmt%2Freplicas%2F1&part=20250728_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.6.10636.altinitytest (altinity build)) '. (RECEIVED_ERROR_FROM_REMOTE_IO_SERVER), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.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 const&, int&&, String const&, unsigned long&&, String const&) @ 0x000000000feda8d9 4. /build/src/IO/HTTPCommon.cpp:104: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x000000000feda6e2 5. /build/src/IO/HTTPCommon.cpp:93: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x000000000feda537 6. /build/src/IO/ReadWriteBufferFromHTTP.cpp:277: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x000000001184a4c4 7. /build/src/IO/ReadWriteBufferFromHTTP.cpp:285: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x000000001184a615 8. /build/src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x000000001184ae59 9. /build/src/IO/ReadWriteBufferFromHTTP.cpp:472: void std::__function::__policy_invoker::__call_impl[abi:se190107]>(std::__function::__policy_storage const*) @ 0x000000001184cedd 10. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001184858b 11. /build/src/IO/ReadWriteBufferFromHTTP.cpp:465: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x000000001184bf0b 12. /build/src/IO/ReadBuffer.h:60: DB::ReadBuffer::next() @ 0x000000000a148c7b 13. /build/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) @ 0x0000000011849fb2 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]>&)>&, 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&) @ 0x0000000011841980 15. /build/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) @ 0x000000001621208e 16. /build/src/Storages/StorageReplicatedMergeTree.cpp:5228: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl[abi:se190107] const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000015f9a5fe 17. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000015ed8bfd 18. /build/src/Storages/StorageReplicatedMergeTree.cpp:2514: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x0000000015ec9aab 19. /build/src/Storages/StorageReplicatedMergeTree.cpp:2349: DB::StorageReplicatedMergeTree::executeLogEntry(DB::ReplicatedMergeTreeLogEntry&) @ 0x0000000015eba91b 20. /build/src/Storages/StorageReplicatedMergeTree.cpp:3876: bool std::__function::__policy_invoker&)>::__call_impl[abi:se190107])::$_1, bool (std::shared_ptr&)>>(std::__function::__policy_storage const*, std::shared_ptr&) @ 0x0000000015f9837e 21. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000165d6fc3 22. /build/src/Storages/StorageReplicatedMergeTree.cpp:3872: DB::StorageReplicatedMergeTree::processQueueEntry(std::shared_ptr) @ 0x0000000015efc18a 23. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001624c1b2 24. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000162f9c70 25. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x00000000162fa55a 26. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc6653 27. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000000fccc4c3 28. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc3d92 29. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fcca080 30. ? @ 0x00007fbc6213eac3 31. ? @ 0x00007fbc621d0850 (version 25.3.6.10636.altinitytest (altinity build)) 2025.07.28 12:01:30.641765 [ 17252 ] {5de416ab-81b7-4d94-850f-9e5538f2b17f} executeQuery: Code: 131. DB::Exception: String too long for type FixedString(2): In scope SELECT accurateCast('123', 'FixedString(2)'). (TOO_LARGE_STRING_SIZE) (version 25.3.6.10636.altinitytest (altinity build)) (from [::1]:39342) (comment: 01601_accurate_cast.sql) (query 34, line 38) (in query: SELECT accurateCast('123', 'FixedString(2)');), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x000000000a06b56b 4. /build/src/Functions/toFixedString.h:100: COW::immutable_ptr DB::FunctionToFixedString::executeForN<(DB::ConvertToFixedStringExceptionMode)0>(std::vector> const&, unsigned long) @ 0x000000000e8504b7 5. /build/src/Functions/FunctionsConversion.h:3696: COW::immutable_ptr std::__function::__policy_invoker::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)>::__call_impl[abi:se190107] const&, unsigned long) 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) @ 0x0000000012f7d86b 6. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000012ddcb1b 7. /build/src/Functions/IFunction.h:57: DB::IExecutableFunction::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000a08134a 8. /build/src/Functions/IFunction.cpp:351: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d93b02 9. /build/src/Functions/IFunction.cpp:177: DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d93698 10. /build/src/Functions/IFunction.cpp:343: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d93aad 11. /build/src/Functions/IFunction.cpp:424: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d94e1b 12. /build/src/Functions/IFunction.cpp:498: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d95c72 13. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3567: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000014034494 14. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3838: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000014019a9e 15. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3980: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000014018e31 16. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:4304: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000014042fa7 17. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5605: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000014013749 18. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000140127f9 19. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000014011fce 20. /build/src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000001406ce8a 21. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000014973b42 22. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000001497268d 23. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000014974d24 24. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001492924b 25. /build/src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88641 26. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 27. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 28. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 29. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 30. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 31. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 2025.07.28 12:01:30.664443 [ 17252 ] {} TCPHandler: Code: 131. DB::Exception: String too long for type FixedString(2): In scope SELECT accurateCast('123', 'FixedString(2)'). (TOO_LARGE_STRING_SIZE), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x000000000a06b56b 4. /build/src/Functions/toFixedString.h:100: COW::immutable_ptr DB::FunctionToFixedString::executeForN<(DB::ConvertToFixedStringExceptionMode)0>(std::vector> const&, unsigned long) @ 0x000000000e8504b7 5. /build/src/Functions/FunctionsConversion.h:3696: COW::immutable_ptr std::__function::__policy_invoker::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)>::__call_impl[abi:se190107] const&, unsigned long) 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) @ 0x0000000012f7d86b 6. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000012ddcb1b 7. /build/src/Functions/IFunction.h:57: DB::IExecutableFunction::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000a08134a 8. /build/src/Functions/IFunction.cpp:351: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d93b02 9. /build/src/Functions/IFunction.cpp:177: DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d93698 10. /build/src/Functions/IFunction.cpp:343: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d93aad 11. /build/src/Functions/IFunction.cpp:424: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d94e1b 12. /build/src/Functions/IFunction.cpp:498: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d95c72 13. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3567: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000014034494 14. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3838: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000014019a9e 15. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3980: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000014018e31 16. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:4304: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000014042fa7 17. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5605: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000014013749 18. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000140127f9 19. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000014011fce 20. /build/src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000001406ce8a 21. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000014973b42 22. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000001497268d 23. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000014974d24 24. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001492924b 25. /build/src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88641 26. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 27. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 28. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 29. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 30. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 31. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 2025.07.28 12:01:31.293892 [ 17252 ] {c4335e89-d04d-4ad2-8925-8ea6b73d0ca6} executeQuery: Code: 70. DB::Exception: Value -1 cannot be safely converted into type UInt32: In scope SELECT accurateCast(-1, 'DateTime'). (CANNOT_CONVERT_TYPE) (version 25.3.6.10636.altinitytest (altinity build)) (from [::1]:39342) (comment: 01601_accurate_cast.sql) (query 36, line 41) (in query: SELECT accurateCast(-1, 'DateTime');), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception<_BitInt(8) const&, std::basic_string_view> const&>(int, FormatStringHelperImpl::type, std::basic_string_view::type_identity> const&>::type>, std::basic_string_view::type_identity<_BitInt(8) const&>&&, std::basic_string_view::type_identity> const&>&&) @ 0x0000000012f3514b 4. /build/src/Functions/DateTimeTransforms.h:2245: void DB::Transformer, DB::DataTypeDateTime, DB::detail::ToDateTimeTransformSigned, unsigned int, (DB::FormatSettings::DateTimeOverflowBehavior)0>, false, DB::DateTimeAccurateConvertStrategyAdditions>::vector, 4096ul, Allocator, 63ul, 64ul>, Allocator, 4096ul, Allocator, 63ul, 64ul>, 63ul, 64ul>>(DB::PODArray, 4096ul, Allocator, 63ul, 64ul> const&, Allocator, 4096ul, Allocator, 63ul, 64ul>, 63ul, 64ul>&, DateLUTImpl const&, DB::DateTimeAccurateConvertStrategyAdditions const&, Allocator, 4096ul, Allocator, 63ul, 64ul>, 63ul, 64ul>*, unsigned long) @ 0x0000000012f61322 5. /build/src/Functions/DateTimeTransforms.h:2287: COW::immutable_ptr> DB::DateTimeTransformImpl, DB::DataTypeDateTime, DB::detail::ToDateTimeTransformSigned, unsigned int, (DB::FormatSettings::DateTimeOverflowBehavior)0>, false>::execute(std::vector> const&, std::vector::shared_ptr const&, unsigned long, DB::DateTimeTransformImpl, DB::DataTypeDateTime, DB::detail::ToDateTimeTransformSigned, unsigned int, (DB::FormatSettings::DateTimeOverflowBehavior)0>, false> const&) @ 0x0000000012f6102f 6. /build/src/Functions/FunctionsConversion.h:1259: 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::DataTypeDateTime 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::DataTypeDateTime const&)::operator(), DB::DataTypeDateTime>>(DB::DataTypeDateTime const&) const @ 0x0000000012f56fe9 7. /build/src/Core/callOnTypeIndex.h:259: std::function::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)> DB::detail::FunctionCast::createWrapper(std::shared_ptr const&, DB::DataTypeDateTime 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 @ 0x0000000012f55a02 8. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: COW::immutable_ptr std::__function::__policy_invoker::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)>::__call_impl[abi:se190107]::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)> DB::detail::FunctionCast::createWrapper(std::shared_ptr const&, DB::DataTypeDateTime 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) @ 0x0000000012f5588c 9. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000012ddcb1b 10. /build/src/Functions/IFunction.h:57: DB::IExecutableFunction::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000a08134a 11. /build/src/Functions/IFunction.cpp:351: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d93b02 12. /build/src/Functions/IFunction.cpp:177: DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d93698 13. /build/src/Functions/IFunction.cpp:343: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d93aad 14. /build/src/Functions/IFunction.cpp:424: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d94e1b 15. /build/src/Functions/IFunction.cpp:498: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d95c72 16. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3567: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000014034494 17. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3838: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000014019a9e 18. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3980: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000014018e31 19. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:4304: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000014042fa7 20. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5605: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000014013749 21. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000140127f9 22. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000014011fce 23. /build/src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000001406ce8a 24. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000014973b42 25. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000001497268d 26. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000014974d24 27. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001492924b 28. /build/src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88641 29. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 30. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 31. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 2025.07.28 12:01:31.308047 [ 17252 ] {} TCPHandler: Code: 70. DB::Exception: Value -1 cannot be safely converted into type UInt32: In scope SELECT accurateCast(-1, 'DateTime'). (CANNOT_CONVERT_TYPE), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception<_BitInt(8) const&, std::basic_string_view> const&>(int, FormatStringHelperImpl::type, std::basic_string_view::type_identity> const&>::type>, std::basic_string_view::type_identity<_BitInt(8) const&>&&, std::basic_string_view::type_identity> const&>&&) @ 0x0000000012f3514b 4. /build/src/Functions/DateTimeTransforms.h:2245: void DB::Transformer, DB::DataTypeDateTime, DB::detail::ToDateTimeTransformSigned, unsigned int, (DB::FormatSettings::DateTimeOverflowBehavior)0>, false, DB::DateTimeAccurateConvertStrategyAdditions>::vector, 4096ul, Allocator, 63ul, 64ul>, Allocator, 4096ul, Allocator, 63ul, 64ul>, 63ul, 64ul>>(DB::PODArray, 4096ul, Allocator, 63ul, 64ul> const&, Allocator, 4096ul, Allocator, 63ul, 64ul>, 63ul, 64ul>&, DateLUTImpl const&, DB::DateTimeAccurateConvertStrategyAdditions const&, Allocator, 4096ul, Allocator, 63ul, 64ul>, 63ul, 64ul>*, unsigned long) @ 0x0000000012f61322 5. /build/src/Functions/DateTimeTransforms.h:2287: COW::immutable_ptr> DB::DateTimeTransformImpl, DB::DataTypeDateTime, DB::detail::ToDateTimeTransformSigned, unsigned int, (DB::FormatSettings::DateTimeOverflowBehavior)0>, false>::execute(std::vector> const&, std::vector::shared_ptr const&, unsigned long, DB::DateTimeTransformImpl, DB::DataTypeDateTime, DB::detail::ToDateTimeTransformSigned, unsigned int, (DB::FormatSettings::DateTimeOverflowBehavior)0>, false> const&) @ 0x0000000012f6102f 6. /build/src/Functions/FunctionsConversion.h:1259: 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::DataTypeDateTime 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::DataTypeDateTime const&)::operator(), DB::DataTypeDateTime>>(DB::DataTypeDateTime const&) const @ 0x0000000012f56fe9 7. /build/src/Core/callOnTypeIndex.h:259: std::function::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)> DB::detail::FunctionCast::createWrapper(std::shared_ptr const&, DB::DataTypeDateTime 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 @ 0x0000000012f55a02 8. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: COW::immutable_ptr std::__function::__policy_invoker::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)>::__call_impl[abi:se190107]::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)> DB::detail::FunctionCast::createWrapper(std::shared_ptr const&, DB::DataTypeDateTime 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) @ 0x0000000012f5588c 9. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000012ddcb1b 10. /build/src/Functions/IFunction.h:57: DB::IExecutableFunction::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000a08134a 11. /build/src/Functions/IFunction.cpp:351: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d93b02 12. /build/src/Functions/IFunction.cpp:177: DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d93698 13. /build/src/Functions/IFunction.cpp:343: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d93aad 14. /build/src/Functions/IFunction.cpp:424: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d94e1b 15. /build/src/Functions/IFunction.cpp:498: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d95c72 16. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3567: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000014034494 17. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3838: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000014019a9e 18. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3980: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000014018e31 19. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:4304: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000014042fa7 20. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5605: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000014013749 21. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000140127f9 22. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000014011fce 23. /build/src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000001406ce8a 24. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000014973b42 25. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000001497268d 26. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000014974d24 27. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001492924b 28. /build/src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88641 29. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 30. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 31. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 2025.07.28 12:01:31.487126 [ 17252 ] {a8cc26ee-8690-444d-8228-6a8a2e0cd575} executeQuery: Code: 70. DB::Exception: Value 4294967296 cannot be safely converted into type UInt32: In scope SELECT accurateCast(4294967295 + 1, 'DateTime'). (CANNOT_CONVERT_TYPE) (version 25.3.6.10636.altinitytest (altinity build)) (from [::1]:39342) (comment: 01601_accurate_cast.sql) (query 37, line 42) (in query: SELECT accurateCast(0xFFFFFFFF + 1, 'DateTime');), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception> const&>(int, FormatStringHelperImpl::type, std::type_identity> const&>::type>, unsigned long const&, std::basic_string_view> const&) @ 0x0000000012f3138b 4. /build/src/Functions/DateTimeTransforms.h:2245: void DB::Transformer, DB::DataTypeDateTime, DB::detail::ToDateTimeTransform64, false, DB::DateTimeAccurateConvertStrategyAdditions>::vector, 63ul, 64ul>, DB::PODArray, 63ul, 64ul>>(DB::PODArray, 63ul, 64ul> const&, DB::PODArray, 63ul, 64ul>&, DateLUTImpl const&, DB::detail::ToDateTimeTransform64 const&, DB::PODArray, 63ul, 64ul>*, unsigned long) @ 0x0000000012f5d9e4 5. /build/src/Functions/DateTimeTransforms.h:2287: COW::immutable_ptr DB::DateTimeTransformImpl, DB::DataTypeDateTime, DB::detail::ToDateTimeTransform64, false>::execute(std::vector> const&, std::shared_ptr const&, unsigned long, DB::detail::ToDateTimeTransform64 const&) @ 0x0000000012f5d6ef 6. /build/src/Functions/FunctionsConversion.h:1265: 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::DataTypeDateTime 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::DataTypeDateTime const&)::operator(), DB::DataTypeDateTime>>(DB::DataTypeDateTime const&) const @ 0x0000000012f56669 7. /build/src/Core/callOnTypeIndex.h:255: std::function::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)> DB::detail::FunctionCast::createWrapper(std::shared_ptr const&, DB::DataTypeDateTime 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 @ 0x0000000012f55a13 8. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: COW::immutable_ptr std::__function::__policy_invoker::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)>::__call_impl[abi:se190107]::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)> DB::detail::FunctionCast::createWrapper(std::shared_ptr const&, DB::DataTypeDateTime 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) @ 0x0000000012f5588c 9. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000012ddcb1b 10. /build/src/Functions/IFunction.h:57: DB::IExecutableFunction::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000a08134a 11. /build/src/Functions/IFunction.cpp:351: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d93b02 12. /build/src/Functions/IFunction.cpp:177: DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d93698 13. /build/src/Functions/IFunction.cpp:343: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d93aad 14. /build/src/Functions/IFunction.cpp:424: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d94e1b 15. /build/src/Functions/IFunction.cpp:498: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d95c72 16. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3567: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000014034494 17. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3838: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000014019a9e 18. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3980: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000014018e31 19. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:4304: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000014042fa7 20. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5605: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000014013749 21. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000140127f9 22. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000014011fce 23. /build/src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000001406ce8a 24. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000014973b42 25. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000001497268d 26. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000014974d24 27. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001492924b 28. /build/src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88641 29. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 30. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 31. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 2025.07.28 12:01:31.496804 [ 17252 ] {} TCPHandler: Code: 70. DB::Exception: Value 4294967296 cannot be safely converted into type UInt32: In scope SELECT accurateCast(4294967295 + 1, 'DateTime'). (CANNOT_CONVERT_TYPE), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception> const&>(int, FormatStringHelperImpl::type, std::type_identity> const&>::type>, unsigned long const&, std::basic_string_view> const&) @ 0x0000000012f3138b 4. /build/src/Functions/DateTimeTransforms.h:2245: void DB::Transformer, DB::DataTypeDateTime, DB::detail::ToDateTimeTransform64, false, DB::DateTimeAccurateConvertStrategyAdditions>::vector, 63ul, 64ul>, DB::PODArray, 63ul, 64ul>>(DB::PODArray, 63ul, 64ul> const&, DB::PODArray, 63ul, 64ul>&, DateLUTImpl const&, DB::detail::ToDateTimeTransform64 const&, DB::PODArray, 63ul, 64ul>*, unsigned long) @ 0x0000000012f5d9e4 5. /build/src/Functions/DateTimeTransforms.h:2287: COW::immutable_ptr DB::DateTimeTransformImpl, DB::DataTypeDateTime, DB::detail::ToDateTimeTransform64, false>::execute(std::vector> const&, std::shared_ptr const&, unsigned long, DB::detail::ToDateTimeTransform64 const&) @ 0x0000000012f5d6ef 6. /build/src/Functions/FunctionsConversion.h:1265: 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::DataTypeDateTime 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::DataTypeDateTime const&)::operator(), DB::DataTypeDateTime>>(DB::DataTypeDateTime const&) const @ 0x0000000012f56669 7. /build/src/Core/callOnTypeIndex.h:255: std::function::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)> DB::detail::FunctionCast::createWrapper(std::shared_ptr const&, DB::DataTypeDateTime 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 @ 0x0000000012f55a13 8. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: COW::immutable_ptr std::__function::__policy_invoker::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)>::__call_impl[abi:se190107]::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)> DB::detail::FunctionCast::createWrapper(std::shared_ptr const&, DB::DataTypeDateTime 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) @ 0x0000000012f5588c 9. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000012ddcb1b 10. /build/src/Functions/IFunction.h:57: DB::IExecutableFunction::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000a08134a 11. /build/src/Functions/IFunction.cpp:351: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d93b02 12. /build/src/Functions/IFunction.cpp:177: DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d93698 13. /build/src/Functions/IFunction.cpp:343: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d93aad 14. /build/src/Functions/IFunction.cpp:424: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d94e1b 15. /build/src/Functions/IFunction.cpp:498: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d95c72 16. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3567: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000014034494 17. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3838: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000014019a9e 18. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3980: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000014018e31 19. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:4304: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000014042fa7 20. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5605: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000014013749 21. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000140127f9 22. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000014011fce 23. /build/src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000001406ce8a 24. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000014973b42 25. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000001497268d 26. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000014974d24 27. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001492924b 28. /build/src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88641 29. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 30. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 31. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 2025.07.28 12:01:31.519154 [ 3960 ] {} test_13.rmt2 (7f9b740d-015c-470e-8cc6-8ba33be0dc63): auto DB::StorageReplicatedMergeTree::processQueueEntry(ReplicatedMergeTreeQueue::SelectedEntryPtr)::(anonymous class)::operator()(LogEntryPtr &) const: Code: 86. DB::HTTPException: Received error from remote server http://146b4357c08d:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Ftest%2F01165%2Ftest_13%2Frmt%2Freplicas%2F1&part=20250728_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.6.10636.altinitytest (altinity build)) '. (RECEIVED_ERROR_FROM_REMOTE_IO_SERVER), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.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 const&, int&&, String const&, unsigned long&&, String const&) @ 0x000000000feda8d9 4. /build/src/IO/HTTPCommon.cpp:104: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x000000000feda6e2 5. /build/src/IO/HTTPCommon.cpp:93: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x000000000feda537 6. /build/src/IO/ReadWriteBufferFromHTTP.cpp:277: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x000000001184a4c4 7. /build/src/IO/ReadWriteBufferFromHTTP.cpp:285: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x000000001184a615 8. /build/src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x000000001184ae59 9. /build/src/IO/ReadWriteBufferFromHTTP.cpp:472: void std::__function::__policy_invoker::__call_impl[abi:se190107]>(std::__function::__policy_storage const*) @ 0x000000001184cedd 10. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001184858b 11. /build/src/IO/ReadWriteBufferFromHTTP.cpp:465: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x000000001184bf0b 12. /build/src/IO/ReadBuffer.h:60: DB::ReadBuffer::next() @ 0x000000000a148c7b 13. /build/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) @ 0x0000000011849fb2 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]>&)>&, 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&) @ 0x0000000011841980 15. /build/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) @ 0x000000001621208e 16. /build/src/Storages/StorageReplicatedMergeTree.cpp:5228: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl[abi:se190107] const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000015f9a5fe 17. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000015ed8bfd 18. /build/src/Storages/StorageReplicatedMergeTree.cpp:2514: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x0000000015ec9aab 19. /build/src/Storages/StorageReplicatedMergeTree.cpp:2349: DB::StorageReplicatedMergeTree::executeLogEntry(DB::ReplicatedMergeTreeLogEntry&) @ 0x0000000015eba91b 20. /build/src/Storages/StorageReplicatedMergeTree.cpp:3876: bool std::__function::__policy_invoker&)>::__call_impl[abi:se190107])::$_1, bool (std::shared_ptr&)>>(std::__function::__policy_storage const*, std::shared_ptr&) @ 0x0000000015f9837e 21. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000165d6fc3 22. /build/src/Storages/StorageReplicatedMergeTree.cpp:3872: DB::StorageReplicatedMergeTree::processQueueEntry(std::shared_ptr) @ 0x0000000015efc18a 23. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001624c1b2 24. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000162f9c70 25. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x00000000162fa55a 26. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc6653 27. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000000fccc4c3 28. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc3d92 29. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fcca080 30. ? @ 0x00007fbc6213eac3 31. ? @ 0x00007fbc621d0850 (version 25.3.6.10636.altinitytest (altinity build)) 2025.07.28 12:01:31.669919 [ 17252 ] {1b560023-fbfa-4df3-ad0f-a04b03a201dd} executeQuery: Code: 41. DB::Exception: Cannot parse DateTime: Cannot parse DateTime from String: In scope SELECT accurateCast('1xxx', 'DateTime'). (CANNOT_PARSE_DATETIME) (version 25.3.6.10636.altinitytest (altinity build)) (from [::1]:39342) (comment: 01601_accurate_cast.sql) (query 38, line 43) (in query: SELECT accurateCast('1xxx', 'DateTime');), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000000a074fcb 4. /build/src/IO/ReadHelpers.cpp:1597: void DB::readDateTimeTextFallback(long&, DB::ReadBuffer&, DateLUTImpl const&, char const*, char const*) @ 0x000000000fc7bf61 5. /build/src/IO/ReadHelpers.h:1216: COW::immutable_ptr DB::detail::ConvertThroughParsing::execute(std::vector> const&, std::shared_ptr const&, unsigned long, void*) @ 0x00000000130a36f5 6. /build/src/Functions/FunctionsConversion.h:1580: COW::immutable_ptr DB::detail::ConvertImpl::execute(std::vector> const&, std::shared_ptr const&, unsigned long, DB::detail::BehaviourOnErrorFromString, void*) @ 0x00000000130a33fe 7. /build/src/Functions/FunctionsConversion.h:2472: 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&&) @ 0x0000000012fa8af0 8. /build/src/Functions/FunctionsConversion.h:2527: DB::detail::FunctionConvert::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000012fc3763 9. /build/src/Functions/FunctionsConversion.h:2307: DB::detail::FunctionConvert::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000012fc2eda 10. /build/src/Functions/IFunctionAdaptors.cpp:10: DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000012d995fa 11. /build/src/Functions/IFunction.cpp:353: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d93b52 12. /build/src/Functions/IFunction.cpp:420: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d95059 13. /build/src/Functions/IFunction.cpp:498: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d95c72 14. /build/src/Functions/IFunction.cpp:513: DB::IFunctionBase::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d96059 15. /build/src/Functions/FunctionsConversion.h:3487: COW::immutable_ptr std::__function::__policy_invoker::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)>::__call_impl[abi:se190107], 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) @ 0x0000000012e00996 16. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000012ddcb1b 17. /build/src/Functions/IFunction.h:57: DB::IExecutableFunction::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000a08134a 18. /build/src/Functions/IFunction.cpp:351: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d93b02 19. /build/src/Functions/IFunction.cpp:177: DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d93698 20. /build/src/Functions/IFunction.cpp:343: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d93aad 21. /build/src/Functions/IFunction.cpp:424: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d94e1b 22. /build/src/Functions/IFunction.cpp:498: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d95c72 23. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3567: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000014034494 24. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3838: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000014019a9e 25. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3980: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000014018e31 26. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:4304: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000014042fa7 27. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5605: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000014013749 28. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000140127f9 29. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000014011fce 30. /build/src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000001406ce8a 31. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000014973b42 2025.07.28 12:01:31.682329 [ 17252 ] {} TCPHandler: Code: 41. DB::Exception: Cannot parse DateTime: Cannot parse DateTime from String: In scope SELECT accurateCast('1xxx', 'DateTime'). (CANNOT_PARSE_DATETIME), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000000a074fcb 4. /build/src/IO/ReadHelpers.cpp:1597: void DB::readDateTimeTextFallback(long&, DB::ReadBuffer&, DateLUTImpl const&, char const*, char const*) @ 0x000000000fc7bf61 5. /build/src/IO/ReadHelpers.h:1216: COW::immutable_ptr DB::detail::ConvertThroughParsing::execute(std::vector> const&, std::shared_ptr const&, unsigned long, void*) @ 0x00000000130a36f5 6. /build/src/Functions/FunctionsConversion.h:1580: COW::immutable_ptr DB::detail::ConvertImpl::execute(std::vector> const&, std::shared_ptr const&, unsigned long, DB::detail::BehaviourOnErrorFromString, void*) @ 0x00000000130a33fe 7. /build/src/Functions/FunctionsConversion.h:2472: 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&&) @ 0x0000000012fa8af0 8. /build/src/Functions/FunctionsConversion.h:2527: DB::detail::FunctionConvert::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000012fc3763 9. /build/src/Functions/FunctionsConversion.h:2307: DB::detail::FunctionConvert::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000012fc2eda 10. /build/src/Functions/IFunctionAdaptors.cpp:10: DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000012d995fa 11. /build/src/Functions/IFunction.cpp:353: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d93b52 12. /build/src/Functions/IFunction.cpp:420: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d95059 13. /build/src/Functions/IFunction.cpp:498: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d95c72 14. /build/src/Functions/IFunction.cpp:513: DB::IFunctionBase::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d96059 15. /build/src/Functions/FunctionsConversion.h:3487: COW::immutable_ptr std::__function::__policy_invoker::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)>::__call_impl[abi:se190107], 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) @ 0x0000000012e00996 16. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000012ddcb1b 17. /build/src/Functions/IFunction.h:57: DB::IExecutableFunction::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000a08134a 18. /build/src/Functions/IFunction.cpp:351: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d93b02 19. /build/src/Functions/IFunction.cpp:177: DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d93698 20. /build/src/Functions/IFunction.cpp:343: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d93aad 21. /build/src/Functions/IFunction.cpp:424: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d94e1b 22. /build/src/Functions/IFunction.cpp:498: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d95c72 23. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3567: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000014034494 24. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3838: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000014019a9e 25. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3980: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000014018e31 26. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:4304: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000014042fa7 27. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5605: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000014013749 28. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000140127f9 29. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000014011fce 30. /build/src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000001406ce8a 31. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000014973b42 2025.07.28 12:01:32.258191 [ 17252 ] {7522912f-fb3f-4175-ba0e-4b3c039bc600} executeQuery: Code: 70. DB::Exception: Value -1 cannot be safely converted into type UInt16: In scope SELECT accurateCast(-1, 'Date'). (CANNOT_CONVERT_TYPE) (version 25.3.6.10636.altinitytest (altinity build)) (from [::1]:39342) (comment: 01601_accurate_cast.sql) (query 41, line 47) (in query: SELECT accurateCast(-1, 'Date');), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception<_BitInt(8) const&, std::basic_string_view> const&>(int, FormatStringHelperImpl::type, std::basic_string_view::type_identity> const&>::type>, std::basic_string_view::type_identity<_BitInt(8) const&>&&, std::basic_string_view::type_identity> const&>&&) @ 0x0000000012f3514b 4. /build/src/Functions/DateTimeTransforms.h:2245: void DB::Transformer, DB::DataTypeDate, DB::detail::ToDateTransform8Or16Signed, (DB::FormatSettings::DateTimeOverflowBehavior)0>, false, DB::DateTimeAccurateConvertStrategyAdditions>::vector, 4096ul, Allocator, 63ul, 64ul>, Allocator, 4096ul, Allocator, 63ul, 64ul>, 63ul, 64ul>>(DB::PODArray, 4096ul, Allocator, 63ul, 64ul> const&, Allocator, 4096ul, Allocator, 63ul, 64ul>, 63ul, 64ul>&, DateLUTImpl const&, DB::DateTimeAccurateConvertStrategyAdditions const&, Allocator, 4096ul, Allocator, 63ul, 64ul>, 63ul, 64ul>*, unsigned long) @ 0x0000000012f350d8 5. /build/src/Functions/DateTimeTransforms.h:2296: COW::immutable_ptr> DB::DateTimeTransformImpl, DB::DataTypeDate, DB::detail::ToDateTransform8Or16Signed, (DB::FormatSettings::DateTimeOverflowBehavior)0>, false>::execute(std::vector> const&, std::vector::shared_ptr const&, unsigned long, DB::DateTimeTransformImpl, DB::DataTypeDate, DB::detail::ToDateTransform8Or16Signed, (DB::FormatSettings::DateTimeOverflowBehavior)0>, false> const&) @ 0x0000000012f34e29 6. /build/src/Functions/FunctionsConversion.h:1213: 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::DataTypeDate 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::DataTypeDate const&)::operator(), DB::DataTypeDate>>(DB::DataTypeDate const&) const @ 0x0000000012f2b7a9 7. /build/src/Core/callOnTypeIndex.h:259: std::function::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)> DB::detail::FunctionCast::createWrapper(std::shared_ptr const&, DB::DataTypeDate 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 @ 0x0000000012f2a082 8. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: COW::immutable_ptr std::__function::__policy_invoker::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)>::__call_impl[abi:se190107]::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)> DB::detail::FunctionCast::createWrapper(std::shared_ptr const&, DB::DataTypeDate 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) @ 0x0000000012f29f0c 9. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000012ddcb1b 10. /build/src/Functions/IFunction.h:57: DB::IExecutableFunction::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000a08134a 11. /build/src/Functions/IFunction.cpp:351: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d93b02 12. /build/src/Functions/IFunction.cpp:177: DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d93698 13. /build/src/Functions/IFunction.cpp:343: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d93aad 14. /build/src/Functions/IFunction.cpp:424: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d94e1b 15. /build/src/Functions/IFunction.cpp:498: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d95c72 16. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3567: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000014034494 17. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3838: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000014019a9e 18. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3980: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000014018e31 19. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:4304: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000014042fa7 20. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5605: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000014013749 21. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000140127f9 22. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000014011fce 23. /build/src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000001406ce8a 24. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000014973b42 25. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000001497268d 26. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000014974d24 27. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001492924b 28. /build/src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88641 29. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 30. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 31. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 2025.07.28 12:01:32.274633 [ 17252 ] {} TCPHandler: Code: 70. DB::Exception: Value -1 cannot be safely converted into type UInt16: In scope SELECT accurateCast(-1, 'Date'). (CANNOT_CONVERT_TYPE), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception<_BitInt(8) const&, std::basic_string_view> const&>(int, FormatStringHelperImpl::type, std::basic_string_view::type_identity> const&>::type>, std::basic_string_view::type_identity<_BitInt(8) const&>&&, std::basic_string_view::type_identity> const&>&&) @ 0x0000000012f3514b 4. /build/src/Functions/DateTimeTransforms.h:2245: void DB::Transformer, DB::DataTypeDate, DB::detail::ToDateTransform8Or16Signed, (DB::FormatSettings::DateTimeOverflowBehavior)0>, false, DB::DateTimeAccurateConvertStrategyAdditions>::vector, 4096ul, Allocator, 63ul, 64ul>, Allocator, 4096ul, Allocator, 63ul, 64ul>, 63ul, 64ul>>(DB::PODArray, 4096ul, Allocator, 63ul, 64ul> const&, Allocator, 4096ul, Allocator, 63ul, 64ul>, 63ul, 64ul>&, DateLUTImpl const&, DB::DateTimeAccurateConvertStrategyAdditions const&, Allocator, 4096ul, Allocator, 63ul, 64ul>, 63ul, 64ul>*, unsigned long) @ 0x0000000012f350d8 5. /build/src/Functions/DateTimeTransforms.h:2296: COW::immutable_ptr> DB::DateTimeTransformImpl, DB::DataTypeDate, DB::detail::ToDateTransform8Or16Signed, (DB::FormatSettings::DateTimeOverflowBehavior)0>, false>::execute(std::vector> const&, std::vector::shared_ptr const&, unsigned long, DB::DateTimeTransformImpl, DB::DataTypeDate, DB::detail::ToDateTransform8Or16Signed, (DB::FormatSettings::DateTimeOverflowBehavior)0>, false> const&) @ 0x0000000012f34e29 6. /build/src/Functions/FunctionsConversion.h:1213: 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::DataTypeDate 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::DataTypeDate const&)::operator(), DB::DataTypeDate>>(DB::DataTypeDate const&) const @ 0x0000000012f2b7a9 7. /build/src/Core/callOnTypeIndex.h:259: std::function::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)> DB::detail::FunctionCast::createWrapper(std::shared_ptr const&, DB::DataTypeDate 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 @ 0x0000000012f2a082 8. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: COW::immutable_ptr std::__function::__policy_invoker::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)>::__call_impl[abi:se190107]::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)> DB::detail::FunctionCast::createWrapper(std::shared_ptr const&, DB::DataTypeDate 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) @ 0x0000000012f29f0c 9. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000012ddcb1b 10. /build/src/Functions/IFunction.h:57: DB::IExecutableFunction::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000a08134a 11. /build/src/Functions/IFunction.cpp:351: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d93b02 12. /build/src/Functions/IFunction.cpp:177: DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d93698 13. /build/src/Functions/IFunction.cpp:343: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d93aad 14. /build/src/Functions/IFunction.cpp:424: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d94e1b 15. /build/src/Functions/IFunction.cpp:498: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d95c72 16. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3567: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000014034494 17. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3838: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000014019a9e 18. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3980: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000014018e31 19. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:4304: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000014042fa7 20. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5605: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000014013749 21. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000140127f9 22. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000014011fce 23. /build/src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000001406ce8a 24. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000014973b42 25. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000001497268d 26. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000014974d24 27. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001492924b 28. /build/src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88641 29. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 30. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 31. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 2025.07.28 12:01:32.399414 [ 17252 ] {79bf6519-4878-4b5e-b262-fcb49d772163} executeQuery: Code: 70. DB::Exception: Value 4294967296 cannot be safely converted into type UInt16: In scope SELECT accurateCast(4294967295 + 1, 'Date'). (CANNOT_CONVERT_TYPE) (version 25.3.6.10636.altinitytest (altinity build)) (from [::1]:39342) (comment: 01601_accurate_cast.sql) (query 42, line 48) (in query: SELECT accurateCast(0xFFFFFFFF + 1, 'Date');), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception> const&>(int, FormatStringHelperImpl::type, std::type_identity> const&>::type>, unsigned long const&, std::basic_string_view> const&) @ 0x0000000012f3138b 4. /build/src/Functions/DateTimeTransforms.h:2245: void DB::Transformer, DB::DataTypeDate, DB::detail::ToDateTransform32Or64, false, DB::DateTimeAccurateConvertStrategyAdditions>::vector, 63ul, 64ul>, DB::PODArray, 63ul, 64ul>>(DB::PODArray, 63ul, 64ul> const&, DB::PODArray, 63ul, 64ul>&, DateLUTImpl const&, DB::detail::ToDateTransform32Or64 const&, DB::PODArray, 63ul, 64ul>*, unsigned long) @ 0x0000000012f3131c 5. /build/src/Functions/DateTimeTransforms.h:2296: COW::immutable_ptr DB::DateTimeTransformImpl, DB::DataTypeDate, DB::detail::ToDateTransform32Or64, false>::execute(std::vector> const&, std::shared_ptr const&, unsigned long, DB::detail::ToDateTransform32Or64 const&) @ 0x0000000012f30fe9 6. /build/src/Functions/FunctionsConversion.h:1205: 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::DataTypeDate 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::DataTypeDate const&)::operator(), DB::DataTypeDate>>(DB::DataTypeDate const&) const @ 0x0000000012f2ae29 7. /build/src/Core/callOnTypeIndex.h:255: std::function::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)> DB::detail::FunctionCast::createWrapper(std::shared_ptr const&, DB::DataTypeDate 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 @ 0x0000000012f2a093 8. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: COW::immutable_ptr std::__function::__policy_invoker::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)>::__call_impl[abi:se190107]::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)> DB::detail::FunctionCast::createWrapper(std::shared_ptr const&, DB::DataTypeDate 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) @ 0x0000000012f29f0c 9. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000012ddcb1b 10. /build/src/Functions/IFunction.h:57: DB::IExecutableFunction::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000a08134a 11. /build/src/Functions/IFunction.cpp:351: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d93b02 12. /build/src/Functions/IFunction.cpp:177: DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d93698 13. /build/src/Functions/IFunction.cpp:343: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d93aad 14. /build/src/Functions/IFunction.cpp:424: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d94e1b 15. /build/src/Functions/IFunction.cpp:498: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d95c72 16. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3567: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000014034494 17. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3838: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000014019a9e 18. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3980: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000014018e31 19. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:4304: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000014042fa7 20. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5605: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000014013749 21. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000140127f9 22. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000014011fce 23. /build/src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000001406ce8a 24. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000014973b42 25. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000001497268d 26. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000014974d24 27. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001492924b 28. /build/src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88641 29. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 30. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 31. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 2025.07.28 12:01:32.407867 [ 17252 ] {} TCPHandler: Code: 70. DB::Exception: Value 4294967296 cannot be safely converted into type UInt16: In scope SELECT accurateCast(4294967295 + 1, 'Date'). (CANNOT_CONVERT_TYPE), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception> const&>(int, FormatStringHelperImpl::type, std::type_identity> const&>::type>, unsigned long const&, std::basic_string_view> const&) @ 0x0000000012f3138b 4. /build/src/Functions/DateTimeTransforms.h:2245: void DB::Transformer, DB::DataTypeDate, DB::detail::ToDateTransform32Or64, false, DB::DateTimeAccurateConvertStrategyAdditions>::vector, 63ul, 64ul>, DB::PODArray, 63ul, 64ul>>(DB::PODArray, 63ul, 64ul> const&, DB::PODArray, 63ul, 64ul>&, DateLUTImpl const&, DB::detail::ToDateTransform32Or64 const&, DB::PODArray, 63ul, 64ul>*, unsigned long) @ 0x0000000012f3131c 5. /build/src/Functions/DateTimeTransforms.h:2296: COW::immutable_ptr DB::DateTimeTransformImpl, DB::DataTypeDate, DB::detail::ToDateTransform32Or64, false>::execute(std::vector> const&, std::shared_ptr const&, unsigned long, DB::detail::ToDateTransform32Or64 const&) @ 0x0000000012f30fe9 6. /build/src/Functions/FunctionsConversion.h:1205: 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::DataTypeDate 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::DataTypeDate const&)::operator(), DB::DataTypeDate>>(DB::DataTypeDate const&) const @ 0x0000000012f2ae29 7. /build/src/Core/callOnTypeIndex.h:255: std::function::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)> DB::detail::FunctionCast::createWrapper(std::shared_ptr const&, DB::DataTypeDate 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 @ 0x0000000012f2a093 8. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: COW::immutable_ptr std::__function::__policy_invoker::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)>::__call_impl[abi:se190107]::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)> DB::detail::FunctionCast::createWrapper(std::shared_ptr const&, DB::DataTypeDate 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) @ 0x0000000012f29f0c 9. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000012ddcb1b 10. /build/src/Functions/IFunction.h:57: DB::IExecutableFunction::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000a08134a 11. /build/src/Functions/IFunction.cpp:351: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d93b02 12. /build/src/Functions/IFunction.cpp:177: DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d93698 13. /build/src/Functions/IFunction.cpp:343: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d93aad 14. /build/src/Functions/IFunction.cpp:424: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d94e1b 15. /build/src/Functions/IFunction.cpp:498: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d95c72 16. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3567: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000014034494 17. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3838: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000014019a9e 18. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3980: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000014018e31 19. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:4304: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000014042fa7 20. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5605: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000014013749 21. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000140127f9 22. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000014011fce 23. /build/src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000001406ce8a 24. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000014973b42 25. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000001497268d 26. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000014974d24 27. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001492924b 28. /build/src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88641 29. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 30. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 31. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 2025.07.28 12:01:32.465663 [ 3970 ] {} test_13.rmt2 (7f9b740d-015c-470e-8cc6-8ba33be0dc63): auto DB::StorageReplicatedMergeTree::processQueueEntry(ReplicatedMergeTreeQueue::SelectedEntryPtr)::(anonymous class)::operator()(LogEntryPtr &) const: Code: 86. DB::HTTPException: Received error from remote server http://146b4357c08d:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Ftest%2F01165%2Ftest_13%2Frmt%2Freplicas%2F1&part=20250728_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.6.10636.altinitytest (altinity build)) '. (RECEIVED_ERROR_FROM_REMOTE_IO_SERVER), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.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 const&, int&&, String const&, unsigned long&&, String const&) @ 0x000000000feda8d9 4. /build/src/IO/HTTPCommon.cpp:104: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x000000000feda6e2 5. /build/src/IO/HTTPCommon.cpp:93: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x000000000feda537 6. /build/src/IO/ReadWriteBufferFromHTTP.cpp:277: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x000000001184a4c4 7. /build/src/IO/ReadWriteBufferFromHTTP.cpp:285: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x000000001184a615 8. /build/src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x000000001184ae59 9. /build/src/IO/ReadWriteBufferFromHTTP.cpp:472: void std::__function::__policy_invoker::__call_impl[abi:se190107]>(std::__function::__policy_storage const*) @ 0x000000001184cedd 10. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001184858b 11. /build/src/IO/ReadWriteBufferFromHTTP.cpp:465: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x000000001184bf0b 12. /build/src/IO/ReadBuffer.h:60: DB::ReadBuffer::next() @ 0x000000000a148c7b 13. /build/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) @ 0x0000000011849fb2 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]>&)>&, 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&) @ 0x0000000011841980 15. /build/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) @ 0x000000001621208e 16. /build/src/Storages/StorageReplicatedMergeTree.cpp:5228: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl[abi:se190107] const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000015f9a5fe 17. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000015ed8bfd 18. /build/src/Storages/StorageReplicatedMergeTree.cpp:2514: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x0000000015ec9aab 19. /build/src/Storages/StorageReplicatedMergeTree.cpp:2349: DB::StorageReplicatedMergeTree::executeLogEntry(DB::ReplicatedMergeTreeLogEntry&) @ 0x0000000015eba91b 20. /build/src/Storages/StorageReplicatedMergeTree.cpp:3876: bool std::__function::__policy_invoker&)>::__call_impl[abi:se190107])::$_1, bool (std::shared_ptr&)>>(std::__function::__policy_storage const*, std::shared_ptr&) @ 0x0000000015f9837e 21. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000165d6fc3 22. /build/src/Storages/StorageReplicatedMergeTree.cpp:3872: DB::StorageReplicatedMergeTree::processQueueEntry(std::shared_ptr) @ 0x0000000015efc18a 23. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001624c1b2 24. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000162f9c70 25. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x00000000162fa55a 26. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc6653 27. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000000fccc4c3 28. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc3d92 29. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fcca080 30. ? @ 0x00007fbc6213eac3 31. ? @ 0x00007fbc621d0850 (version 25.3.6.10636.altinitytest (altinity build)) 2025.07.28 12:01:32.711254 [ 17252 ] {9fa5b294-3421-403f-88a6-75f75a63579a} executeQuery: Code: 38. DB::Exception: Cannot parse date: value is too short: Cannot parse Date from String: In scope SELECT accurateCast('1xxx', 'Date'). (CANNOT_PARSE_DATE) (version 25.3.6.10636.altinitytest (altinity build)) (from [::1]:39342) (comment: 01601_accurate_cast.sql) (query 43, line 49) (in query: SELECT accurateCast('1xxx', 'Date');), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000000a074fcb 4. /build/src/IO/ReadHelpers.cpp:1389: void DB::readDateTextFallback(LocalDate&, DB::ReadBuffer&, char const*) @ 0x000000000fc7b73d 5. /build/src/IO/ReadHelpers.h:850: COW::immutable_ptr DB::detail::ConvertThroughParsing::execute(std::vector> const&, std::shared_ptr const&, unsigned long, void*) @ 0x000000001306cac5 6. /build/src/Functions/FunctionsConversion.h:1580: COW::immutable_ptr DB::detail::ConvertImpl::execute(std::vector> const&, std::shared_ptr const&, unsigned long, DB::detail::BehaviourOnErrorFromString, void*) @ 0x000000001306c7fe 7. /build/src/Functions/FunctionsConversion.h:2472: 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&&) @ 0x0000000012fa7c30 8. /build/src/Functions/FunctionsConversion.h:2527: DB::detail::FunctionConvert::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000012fc0b8e 9. /build/src/Functions/FunctionsConversion.h:2307: DB::detail::FunctionConvert::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000012fc03ba 10. /build/src/Functions/IFunctionAdaptors.cpp:10: DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000012d995fa 11. /build/src/Functions/IFunction.cpp:353: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d93b52 12. /build/src/Functions/IFunction.cpp:420: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d95059 13. /build/src/Functions/IFunction.cpp:498: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d95c72 14. /build/src/Functions/IFunction.cpp:513: DB::IFunctionBase::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d96059 15. /build/src/Functions/FunctionsConversion.h:3487: COW::immutable_ptr std::__function::__policy_invoker::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)>::__call_impl[abi:se190107], 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) @ 0x0000000012e00996 16. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000012ddcb1b 17. /build/src/Functions/IFunction.h:57: DB::IExecutableFunction::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000a08134a 18. /build/src/Functions/IFunction.cpp:351: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d93b02 19. /build/src/Functions/IFunction.cpp:177: DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d93698 20. /build/src/Functions/IFunction.cpp:343: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d93aad 21. /build/src/Functions/IFunction.cpp:424: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d94e1b 22. /build/src/Functions/IFunction.cpp:498: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d95c72 23. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3567: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000014034494 24. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3838: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000014019a9e 25. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3980: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000014018e31 26. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:4304: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000014042fa7 27. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5605: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000014013749 28. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000140127f9 29. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000014011fce 30. /build/src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000001406ce8a 31. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000014973b42 2025.07.28 12:01:32.720851 [ 17252 ] {} TCPHandler: Code: 38. DB::Exception: Cannot parse date: value is too short: Cannot parse Date from String: In scope SELECT accurateCast('1xxx', 'Date'). (CANNOT_PARSE_DATE), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000000a074fcb 4. /build/src/IO/ReadHelpers.cpp:1389: void DB::readDateTextFallback(LocalDate&, DB::ReadBuffer&, char const*) @ 0x000000000fc7b73d 5. /build/src/IO/ReadHelpers.h:850: COW::immutable_ptr DB::detail::ConvertThroughParsing::execute(std::vector> const&, std::shared_ptr const&, unsigned long, void*) @ 0x000000001306cac5 6. /build/src/Functions/FunctionsConversion.h:1580: COW::immutable_ptr DB::detail::ConvertImpl::execute(std::vector> const&, std::shared_ptr const&, unsigned long, DB::detail::BehaviourOnErrorFromString, void*) @ 0x000000001306c7fe 7. /build/src/Functions/FunctionsConversion.h:2472: 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&&) @ 0x0000000012fa7c30 8. /build/src/Functions/FunctionsConversion.h:2527: DB::detail::FunctionConvert::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000012fc0b8e 9. /build/src/Functions/FunctionsConversion.h:2307: DB::detail::FunctionConvert::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000012fc03ba 10. /build/src/Functions/IFunctionAdaptors.cpp:10: DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000012d995fa 11. /build/src/Functions/IFunction.cpp:353: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d93b52 12. /build/src/Functions/IFunction.cpp:420: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d95059 13. /build/src/Functions/IFunction.cpp:498: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d95c72 14. /build/src/Functions/IFunction.cpp:513: DB::IFunctionBase::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d96059 15. /build/src/Functions/FunctionsConversion.h:3487: COW::immutable_ptr std::__function::__policy_invoker::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)>::__call_impl[abi:se190107], 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) @ 0x0000000012e00996 16. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000012ddcb1b 17. /build/src/Functions/IFunction.h:57: DB::IExecutableFunction::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000a08134a 18. /build/src/Functions/IFunction.cpp:351: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d93b02 19. /build/src/Functions/IFunction.cpp:177: DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d93698 20. /build/src/Functions/IFunction.cpp:343: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d93aad 21. /build/src/Functions/IFunction.cpp:424: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d94e1b 22. /build/src/Functions/IFunction.cpp:498: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d95c72 23. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3567: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000014034494 24. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3838: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000014019a9e 25. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3980: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000014018e31 26. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:4304: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000014042fa7 27. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5605: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000014013749 28. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000140127f9 29. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000014011fce 30. /build/src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000001406ce8a 31. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000014973b42 2025.07.28 12:01:33.403892 [ 17252 ] {bdf144b2-124c-4269-8d08-66c89018baa1} executeQuery: Code: 467. DB::Exception: Cannot parse boolean value here: 'test', should be 'true' or 'false' controlled by setting bool_true_representation and bool_false_representation or one of True/False/T/F/Y/N/Yes/No/On/Off/Enable/Disable/Enabled/Disabled/1/0: In scope SELECT accurateCast('test', 'Nullable(Bool)'). (CANNOT_PARSE_BOOL) (version 25.3.6.10636.altinitytest (altinity build)) (from [::1]:39342) (comment: 01601_accurate_cast.sql) (query 46, line 53) (in query: select accurateCast('test', 'Nullable(Bool)');), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String const&, String const&) @ 0x000000000a070d0b 4. /build/src/DataTypes/Serializations/SerializationBool.cpp:212: void DB::(anonymous namespace)::deserializeImpl(DB::IColumn&, DB::ReadBuffer&, DB::FormatSettings const&, std::function) @ 0x0000000013c89576 5. /build/src/DataTypes/Serializations/SerializationBool.cpp:449: DB::SerializationBool::deserializeWholeText(DB::IColumn&, DB::ReadBuffer&, DB::FormatSettings const&) const @ 0x0000000013c8a8b3 6. /build/src/DataTypes/Serializations/SerializationNullable.cpp:597: void DB::deserializeWholeTextImpl(DB::IColumn&, DB::ReadBuffer&, DB::FormatSettings const&, std::shared_ptr const&, bool&) @ 0x0000000013cd10d4 7. /build/src/DataTypes/Serializations/SerializationNullable.cpp:608: DB::SerializationNullable::deserializeWholeText(DB::IColumn&, DB::ReadBuffer&, DB::FormatSettings const&) const @ 0x0000000013ccf8bf 8. /build/src/Functions/FunctionsConversion.h:1922: 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&) @ 0x0000000012de920b 9. /build/src/Functions/FunctionsConversion.h:1894: DB::detail::ConvertImplGenericFromString::execute(std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long, std::shared_ptr const&) @ 0x0000000012de7d2d 10. /build/src/Functions/FunctionsConversion.h:6037: bool DB::detail::FunctionCast::prepareImpl(std::shared_ptr const&, std::shared_ptr const&, bool) const::'lambda0'(auto const&)::operator()>>(auto const&) 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 @ 0x0000000012df3bfc 11. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: COW::immutable_ptr std::__function::__policy_invoker::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)>::__call_impl[abi:se190107] const&, std::shared_ptr const&, bool) const::'lambda0'(auto const&)::operator()>>(auto 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) @ 0x0000000012df3b29 12. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000012f974e4 13. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: COW::immutable_ptr std::__function::__policy_invoker::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)>::__call_impl[abi:se190107] 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) @ 0x0000000012f9738c 14. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000012ddcb1b 15. /build/src/Functions/IFunction.h:57: DB::IExecutableFunction::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000a08134a 16. /build/src/Functions/IFunction.cpp:351: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d93b02 17. /build/src/Functions/IFunction.cpp:177: DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d93698 18. /build/src/Functions/IFunction.cpp:343: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d93aad 19. /build/src/Functions/IFunction.cpp:424: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d94e1b 20. /build/src/Functions/IFunction.cpp:498: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d95c72 21. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3567: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000014034494 22. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3838: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000014019a9e 23. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3980: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000014018e31 24. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:4304: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000014042fa7 25. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5605: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000014013749 26. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000140127f9 27. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000014011fce 28. /build/src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000001406ce8a 29. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000014973b42 30. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000001497268d 31. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000014974d24 2025.07.28 12:01:33.434060 [ 3969 ] {} test_13.rmt2 (7f9b740d-015c-470e-8cc6-8ba33be0dc63): auto DB::StorageReplicatedMergeTree::processQueueEntry(ReplicatedMergeTreeQueue::SelectedEntryPtr)::(anonymous class)::operator()(LogEntryPtr &) const: Code: 86. DB::HTTPException: Received error from remote server http://146b4357c08d:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Ftest%2F01165%2Ftest_13%2Frmt%2Freplicas%2F1&part=20250728_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.6.10636.altinitytest (altinity build)) '. (RECEIVED_ERROR_FROM_REMOTE_IO_SERVER), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.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 const&, int&&, String const&, unsigned long&&, String const&) @ 0x000000000feda8d9 4. /build/src/IO/HTTPCommon.cpp:104: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x000000000feda6e2 5. /build/src/IO/HTTPCommon.cpp:93: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x000000000feda537 6. /build/src/IO/ReadWriteBufferFromHTTP.cpp:277: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x000000001184a4c4 7. /build/src/IO/ReadWriteBufferFromHTTP.cpp:285: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x000000001184a615 8. /build/src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x000000001184ae59 9. /build/src/IO/ReadWriteBufferFromHTTP.cpp:472: void std::__function::__policy_invoker::__call_impl[abi:se190107]>(std::__function::__policy_storage const*) @ 0x000000001184cedd 10. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001184858b 11. /build/src/IO/ReadWriteBufferFromHTTP.cpp:465: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x000000001184bf0b 12. /build/src/IO/ReadBuffer.h:60: DB::ReadBuffer::next() @ 0x000000000a148c7b 13. /build/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) @ 0x0000000011849fb2 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]>&)>&, 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&) @ 0x0000000011841980 15. /build/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) @ 0x000000001621208e 16. /build/src/Storages/StorageReplicatedMergeTree.cpp:5228: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl[abi:se190107] const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000015f9a5fe 17. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000015ed8bfd 18. /build/src/Storages/StorageReplicatedMergeTree.cpp:2514: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x0000000015ec9aab 19. /build/src/Storages/StorageReplicatedMergeTree.cpp:2349: DB::StorageReplicatedMergeTree::executeLogEntry(DB::ReplicatedMergeTreeLogEntry&) @ 0x0000000015eba91b 20. /build/src/Storages/StorageReplicatedMergeTree.cpp:3876: bool std::__function::__policy_invoker&)>::__call_impl[abi:se190107])::$_1, bool (std::shared_ptr&)>>(std::__function::__policy_storage const*, std::shared_ptr&) @ 0x0000000015f9837e 21. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000165d6fc3 22. /build/src/Storages/StorageReplicatedMergeTree.cpp:3872: DB::StorageReplicatedMergeTree::processQueueEntry(std::shared_ptr) @ 0x0000000015efc18a 23. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001624c1b2 24. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000162f9c70 25. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x00000000162fa55a 26. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc6653 27. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000000fccc4c3 28. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc3d92 29. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fcca080 30. ? @ 0x00007fbc6213eac3 31. ? @ 0x00007fbc621d0850 (version 25.3.6.10636.altinitytest (altinity build)) 2025.07.28 12:01:33.460524 [ 17252 ] {} TCPHandler: Code: 467. DB::Exception: Cannot parse boolean value here: 'test', should be 'true' or 'false' controlled by setting bool_true_representation and bool_false_representation or one of True/False/T/F/Y/N/Yes/No/On/Off/Enable/Disable/Enabled/Disabled/1/0: In scope SELECT accurateCast('test', 'Nullable(Bool)'). (CANNOT_PARSE_BOOL), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String const&, String const&) @ 0x000000000a070d0b 4. /build/src/DataTypes/Serializations/SerializationBool.cpp:212: void DB::(anonymous namespace)::deserializeImpl(DB::IColumn&, DB::ReadBuffer&, DB::FormatSettings const&, std::function) @ 0x0000000013c89576 5. /build/src/DataTypes/Serializations/SerializationBool.cpp:449: DB::SerializationBool::deserializeWholeText(DB::IColumn&, DB::ReadBuffer&, DB::FormatSettings const&) const @ 0x0000000013c8a8b3 6. /build/src/DataTypes/Serializations/SerializationNullable.cpp:597: void DB::deserializeWholeTextImpl(DB::IColumn&, DB::ReadBuffer&, DB::FormatSettings const&, std::shared_ptr const&, bool&) @ 0x0000000013cd10d4 7. /build/src/DataTypes/Serializations/SerializationNullable.cpp:608: DB::SerializationNullable::deserializeWholeText(DB::IColumn&, DB::ReadBuffer&, DB::FormatSettings const&) const @ 0x0000000013ccf8bf 8. /build/src/Functions/FunctionsConversion.h:1922: 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&) @ 0x0000000012de920b 9. /build/src/Functions/FunctionsConversion.h:1894: DB::detail::ConvertImplGenericFromString::execute(std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long, std::shared_ptr const&) @ 0x0000000012de7d2d 10. /build/src/Functions/FunctionsConversion.h:6037: bool DB::detail::FunctionCast::prepareImpl(std::shared_ptr const&, std::shared_ptr const&, bool) const::'lambda0'(auto const&)::operator()>>(auto const&) 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 @ 0x0000000012df3bfc 11. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: COW::immutable_ptr std::__function::__policy_invoker::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)>::__call_impl[abi:se190107] const&, std::shared_ptr const&, bool) const::'lambda0'(auto const&)::operator()>>(auto 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) @ 0x0000000012df3b29 12. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000012f974e4 13. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: COW::immutable_ptr std::__function::__policy_invoker::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)>::__call_impl[abi:se190107] 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) @ 0x0000000012f9738c 14. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000012ddcb1b 15. /build/src/Functions/IFunction.h:57: DB::IExecutableFunction::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000a08134a 16. /build/src/Functions/IFunction.cpp:351: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d93b02 17. /build/src/Functions/IFunction.cpp:177: DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d93698 18. /build/src/Functions/IFunction.cpp:343: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d93aad 19. /build/src/Functions/IFunction.cpp:424: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d94e1b 20. /build/src/Functions/IFunction.cpp:498: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d95c72 21. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3567: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000014034494 22. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3838: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000014019a9e 23. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3980: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000014018e31 24. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:4304: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000014042fa7 25. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5605: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000014013749 26. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000140127f9 27. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000014011fce 28. /build/src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000001406ce8a 29. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000014973b42 30. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000001497268d 31. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000014974d24 2025.07.28 12:01:33.554979 [ 17252 ] {018c8f56-582c-48ac-9850-2703bf288f7b} executeQuery: Code: 467. DB::Exception: Cannot parse boolean value here: 'test', should be 'true' or 'false' controlled by setting bool_true_representation and bool_false_representation or one of True/False/T/F/Y/N/Yes/No/On/Off/Enable/Disable/Enabled/Disabled/1/0: In scope SELECT accurateCast('test', 'Bool'). (CANNOT_PARSE_BOOL) (version 25.3.6.10636.altinitytest (altinity build)) (from [::1]:39342) (comment: 01601_accurate_cast.sql) (query 47, line 54) (in query: select accurateCast('test', 'Bool');), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String const&, String const&) @ 0x000000000a070d0b 4. /build/src/DataTypes/Serializations/SerializationBool.cpp:212: void DB::(anonymous namespace)::deserializeImpl(DB::IColumn&, DB::ReadBuffer&, DB::FormatSettings const&, std::function) @ 0x0000000013c89576 5. /build/src/DataTypes/Serializations/SerializationBool.cpp:449: DB::SerializationBool::deserializeWholeText(DB::IColumn&, DB::ReadBuffer&, DB::FormatSettings const&) const @ 0x0000000013c8a8b3 6. /build/src/Functions/FunctionsConversion.h:1922: 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&) @ 0x0000000012de920b 7. /build/src/Functions/FunctionsConversion.h:1894: DB::detail::ConvertImplGenericFromString::execute(std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long, std::shared_ptr const&) @ 0x0000000012de7d2d 8. /build/src/Functions/FunctionsConversion.h:6037: bool DB::detail::FunctionCast::prepareImpl(std::shared_ptr const&, std::shared_ptr const&, bool) const::'lambda0'(auto const&)::operator()>>(auto const&) 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 @ 0x0000000012df3bfc 9. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: COW::immutable_ptr std::__function::__policy_invoker::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)>::__call_impl[abi:se190107] const&, std::shared_ptr const&, bool) const::'lambda0'(auto const&)::operator()>>(auto 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) @ 0x0000000012df3b29 10. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000012ddcb1b 11. /build/src/Functions/IFunction.h:57: DB::IExecutableFunction::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000a08134a 12. /build/src/Functions/IFunction.cpp:351: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d93b02 13. /build/src/Functions/IFunction.cpp:177: DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d93698 14. /build/src/Functions/IFunction.cpp:343: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d93aad 15. /build/src/Functions/IFunction.cpp:424: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d94e1b 16. /build/src/Functions/IFunction.cpp:498: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d95c72 17. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3567: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000014034494 18. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3838: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000014019a9e 19. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3980: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000014018e31 20. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:4304: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000014042fa7 21. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5605: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000014013749 22. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000140127f9 23. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000014011fce 24. /build/src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000001406ce8a 25. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000014973b42 26. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000001497268d 27. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000014974d24 28. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001492924b 29. /build/src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88641 30. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 31. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 2025.07.28 12:01:33.585346 [ 17252 ] {} TCPHandler: Code: 467. DB::Exception: Cannot parse boolean value here: 'test', should be 'true' or 'false' controlled by setting bool_true_representation and bool_false_representation or one of True/False/T/F/Y/N/Yes/No/On/Off/Enable/Disable/Enabled/Disabled/1/0: In scope SELECT accurateCast('test', 'Bool'). (CANNOT_PARSE_BOOL), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String const&, String const&) @ 0x000000000a070d0b 4. /build/src/DataTypes/Serializations/SerializationBool.cpp:212: void DB::(anonymous namespace)::deserializeImpl(DB::IColumn&, DB::ReadBuffer&, DB::FormatSettings const&, std::function) @ 0x0000000013c89576 5. /build/src/DataTypes/Serializations/SerializationBool.cpp:449: DB::SerializationBool::deserializeWholeText(DB::IColumn&, DB::ReadBuffer&, DB::FormatSettings const&) const @ 0x0000000013c8a8b3 6. /build/src/Functions/FunctionsConversion.h:1922: 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&) @ 0x0000000012de920b 7. /build/src/Functions/FunctionsConversion.h:1894: DB::detail::ConvertImplGenericFromString::execute(std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long, std::shared_ptr const&) @ 0x0000000012de7d2d 8. /build/src/Functions/FunctionsConversion.h:6037: bool DB::detail::FunctionCast::prepareImpl(std::shared_ptr const&, std::shared_ptr const&, bool) const::'lambda0'(auto const&)::operator()>>(auto const&) 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 @ 0x0000000012df3bfc 9. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: COW::immutable_ptr std::__function::__policy_invoker::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)>::__call_impl[abi:se190107] const&, std::shared_ptr const&, bool) const::'lambda0'(auto const&)::operator()>>(auto 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) @ 0x0000000012df3b29 10. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000012ddcb1b 11. /build/src/Functions/IFunction.h:57: DB::IExecutableFunction::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000a08134a 12. /build/src/Functions/IFunction.cpp:351: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d93b02 13. /build/src/Functions/IFunction.cpp:177: DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d93698 14. /build/src/Functions/IFunction.cpp:343: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d93aad 15. /build/src/Functions/IFunction.cpp:424: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d94e1b 16. /build/src/Functions/IFunction.cpp:498: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d95c72 17. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3567: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000014034494 18. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3838: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000014019a9e 19. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3980: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000014018e31 20. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:4304: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000014042fa7 21. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5605: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000014013749 22. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000140127f9 23. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000014011fce 24. /build/src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000001406ce8a 25. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000014973b42 26. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000001497268d 27. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000014974d24 28. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001492924b 29. /build/src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88641 30. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 31. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 2025.07.28 12:01:33.641599 [ 17252 ] {8e78ca41-04da-4d5e-8072-0a2514bbf736} executeQuery: Code: 467. DB::Exception: Cannot parse boolean value here: 'truex', should be 'true' or 'false' controlled by setting bool_true_representation and bool_false_representation or one of True/False/T/F/Y/N/Yes/No/On/Off/Enable/Disable/Enabled/Disabled/1/0: In scope SELECT accurateCast('truex', 'Bool'). (CANNOT_PARSE_BOOL) (version 25.3.6.10636.altinitytest (altinity build)) (from [::1]:39342) (comment: 01601_accurate_cast.sql) (query 48, line 55) (in query: select accurateCast('truex', 'Bool');), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String const&, String const&) @ 0x000000000a070d0b 4. /build/src/DataTypes/Serializations/SerializationBool.cpp:212: void DB::(anonymous namespace)::deserializeImpl(DB::IColumn&, DB::ReadBuffer&, DB::FormatSettings const&, std::function) @ 0x0000000013c89576 5. /build/src/DataTypes/Serializations/SerializationBool.cpp:449: DB::SerializationBool::deserializeWholeText(DB::IColumn&, DB::ReadBuffer&, DB::FormatSettings const&) const @ 0x0000000013c8a8b3 6. /build/src/Functions/FunctionsConversion.h:1922: 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&) @ 0x0000000012de920b 7. /build/src/Functions/FunctionsConversion.h:1894: DB::detail::ConvertImplGenericFromString::execute(std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long, std::shared_ptr const&) @ 0x0000000012de7d2d 8. /build/src/Functions/FunctionsConversion.h:6037: bool DB::detail::FunctionCast::prepareImpl(std::shared_ptr const&, std::shared_ptr const&, bool) const::'lambda0'(auto const&)::operator()>>(auto const&) 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 @ 0x0000000012df3bfc 9. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: COW::immutable_ptr std::__function::__policy_invoker::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)>::__call_impl[abi:se190107] const&, std::shared_ptr const&, bool) const::'lambda0'(auto const&)::operator()>>(auto 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) @ 0x0000000012df3b29 10. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000012ddcb1b 11. /build/src/Functions/IFunction.h:57: DB::IExecutableFunction::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000a08134a 12. /build/src/Functions/IFunction.cpp:351: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d93b02 13. /build/src/Functions/IFunction.cpp:177: DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d93698 14. /build/src/Functions/IFunction.cpp:343: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d93aad 15. /build/src/Functions/IFunction.cpp:424: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d94e1b 16. /build/src/Functions/IFunction.cpp:498: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d95c72 17. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3567: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000014034494 18. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3838: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000014019a9e 19. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3980: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000014018e31 20. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:4304: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000014042fa7 21. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5605: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000014013749 22. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000140127f9 23. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000014011fce 24. /build/src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000001406ce8a 25. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000014973b42 26. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000001497268d 27. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000014974d24 28. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001492924b 29. /build/src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88641 30. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 31. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 2025.07.28 12:01:33.647679 [ 17252 ] {} TCPHandler: Code: 467. DB::Exception: Cannot parse boolean value here: 'truex', should be 'true' or 'false' controlled by setting bool_true_representation and bool_false_representation or one of True/False/T/F/Y/N/Yes/No/On/Off/Enable/Disable/Enabled/Disabled/1/0: In scope SELECT accurateCast('truex', 'Bool'). (CANNOT_PARSE_BOOL), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String const&, String const&) @ 0x000000000a070d0b 4. /build/src/DataTypes/Serializations/SerializationBool.cpp:212: void DB::(anonymous namespace)::deserializeImpl(DB::IColumn&, DB::ReadBuffer&, DB::FormatSettings const&, std::function) @ 0x0000000013c89576 5. /build/src/DataTypes/Serializations/SerializationBool.cpp:449: DB::SerializationBool::deserializeWholeText(DB::IColumn&, DB::ReadBuffer&, DB::FormatSettings const&) const @ 0x0000000013c8a8b3 6. /build/src/Functions/FunctionsConversion.h:1922: 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&) @ 0x0000000012de920b 7. /build/src/Functions/FunctionsConversion.h:1894: DB::detail::ConvertImplGenericFromString::execute(std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long, std::shared_ptr const&) @ 0x0000000012de7d2d 8. /build/src/Functions/FunctionsConversion.h:6037: bool DB::detail::FunctionCast::prepareImpl(std::shared_ptr const&, std::shared_ptr const&, bool) const::'lambda0'(auto const&)::operator()>>(auto const&) 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 @ 0x0000000012df3bfc 9. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: COW::immutable_ptr std::__function::__policy_invoker::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)>::__call_impl[abi:se190107] const&, std::shared_ptr const&, bool) const::'lambda0'(auto const&)::operator()>>(auto 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) @ 0x0000000012df3b29 10. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000012ddcb1b 11. /build/src/Functions/IFunction.h:57: DB::IExecutableFunction::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000a08134a 12. /build/src/Functions/IFunction.cpp:351: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d93b02 13. /build/src/Functions/IFunction.cpp:177: DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d93698 14. /build/src/Functions/IFunction.cpp:343: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d93aad 15. /build/src/Functions/IFunction.cpp:424: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d94e1b 16. /build/src/Functions/IFunction.cpp:498: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d95c72 17. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3567: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000014034494 18. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3838: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000014019a9e 19. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3980: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000014018e31 20. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:4304: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000014042fa7 21. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5605: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000014013749 22. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000140127f9 23. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000014011fce 24. /build/src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000001406ce8a 25. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000014973b42 26. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000001497268d 27. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000014974d24 28. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001492924b 29. /build/src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88641 30. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 31. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 2025.07.28 12:01:33.703684 [ 17252 ] {80bb322f-bfea-4ea2-b961-241ebe7ba5f3} executeQuery: Code: 467. DB::Exception: Cannot parse boolean value here: 'xfalse', should be 'true' or 'false' controlled by setting bool_true_representation and bool_false_representation or one of True/False/T/F/Y/N/Yes/No/On/Off/Enable/Disable/Enabled/Disabled/1/0: In scope SELECT accurateCast('xfalse', 'Bool'). (CANNOT_PARSE_BOOL) (version 25.3.6.10636.altinitytest (altinity build)) (from [::1]:39342) (comment: 01601_accurate_cast.sql) (query 49, line 56) (in query: select accurateCast('xfalse', 'Bool');), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String const&, String const&) @ 0x000000000a070d0b 4. /build/src/DataTypes/Serializations/SerializationBool.cpp:212: void DB::(anonymous namespace)::deserializeImpl(DB::IColumn&, DB::ReadBuffer&, DB::FormatSettings const&, std::function) @ 0x0000000013c89576 5. /build/src/DataTypes/Serializations/SerializationBool.cpp:449: DB::SerializationBool::deserializeWholeText(DB::IColumn&, DB::ReadBuffer&, DB::FormatSettings const&) const @ 0x0000000013c8a8b3 6. /build/src/Functions/FunctionsConversion.h:1922: 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&) @ 0x0000000012de920b 7. /build/src/Functions/FunctionsConversion.h:1894: DB::detail::ConvertImplGenericFromString::execute(std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long, std::shared_ptr const&) @ 0x0000000012de7d2d 8. /build/src/Functions/FunctionsConversion.h:6037: bool DB::detail::FunctionCast::prepareImpl(std::shared_ptr const&, std::shared_ptr const&, bool) const::'lambda0'(auto const&)::operator()>>(auto const&) 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 @ 0x0000000012df3bfc 9. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: COW::immutable_ptr std::__function::__policy_invoker::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)>::__call_impl[abi:se190107] const&, std::shared_ptr const&, bool) const::'lambda0'(auto const&)::operator()>>(auto 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) @ 0x0000000012df3b29 10. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000012ddcb1b 11. /build/src/Functions/IFunction.h:57: DB::IExecutableFunction::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000a08134a 12. /build/src/Functions/IFunction.cpp:351: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d93b02 13. /build/src/Functions/IFunction.cpp:177: DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d93698 14. /build/src/Functions/IFunction.cpp:343: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d93aad 15. /build/src/Functions/IFunction.cpp:424: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d94e1b 16. /build/src/Functions/IFunction.cpp:498: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d95c72 17. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3567: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000014034494 18. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3838: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000014019a9e 19. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3980: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000014018e31 20. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:4304: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000014042fa7 21. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5605: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000014013749 22. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000140127f9 23. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000014011fce 24. /build/src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000001406ce8a 25. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000014973b42 26. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000001497268d 27. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000014974d24 28. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001492924b 29. /build/src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88641 30. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 31. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 2025.07.28 12:01:33.741006 [ 17252 ] {} TCPHandler: Code: 467. DB::Exception: Cannot parse boolean value here: 'xfalse', should be 'true' or 'false' controlled by setting bool_true_representation and bool_false_representation or one of True/False/T/F/Y/N/Yes/No/On/Off/Enable/Disable/Enabled/Disabled/1/0: In scope SELECT accurateCast('xfalse', 'Bool'). (CANNOT_PARSE_BOOL), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String const&, String const&) @ 0x000000000a070d0b 4. /build/src/DataTypes/Serializations/SerializationBool.cpp:212: void DB::(anonymous namespace)::deserializeImpl(DB::IColumn&, DB::ReadBuffer&, DB::FormatSettings const&, std::function) @ 0x0000000013c89576 5. /build/src/DataTypes/Serializations/SerializationBool.cpp:449: DB::SerializationBool::deserializeWholeText(DB::IColumn&, DB::ReadBuffer&, DB::FormatSettings const&) const @ 0x0000000013c8a8b3 6. /build/src/Functions/FunctionsConversion.h:1922: 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&) @ 0x0000000012de920b 7. /build/src/Functions/FunctionsConversion.h:1894: DB::detail::ConvertImplGenericFromString::execute(std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long, std::shared_ptr const&) @ 0x0000000012de7d2d 8. /build/src/Functions/FunctionsConversion.h:6037: bool DB::detail::FunctionCast::prepareImpl(std::shared_ptr const&, std::shared_ptr const&, bool) const::'lambda0'(auto const&)::operator()>>(auto const&) 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 @ 0x0000000012df3bfc 9. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: COW::immutable_ptr std::__function::__policy_invoker::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)>::__call_impl[abi:se190107] const&, std::shared_ptr const&, bool) const::'lambda0'(auto const&)::operator()>>(auto 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) @ 0x0000000012df3b29 10. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000012ddcb1b 11. /build/src/Functions/IFunction.h:57: DB::IExecutableFunction::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000a08134a 12. /build/src/Functions/IFunction.cpp:351: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d93b02 13. /build/src/Functions/IFunction.cpp:177: DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d93698 14. /build/src/Functions/IFunction.cpp:343: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d93aad 15. /build/src/Functions/IFunction.cpp:424: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d94e1b 16. /build/src/Functions/IFunction.cpp:498: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d95c72 17. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3567: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000014034494 18. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3838: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000014019a9e 19. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3980: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000014018e31 20. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:4304: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000014042fa7 21. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5605: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000014013749 22. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000140127f9 23. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000014011fce 24. /build/src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000001406ce8a 25. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000014973b42 26. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000001497268d 27. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000014974d24 28. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001492924b 29. /build/src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88641 30. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 31. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 2025.07.28 12:01:33.788065 [ 3965 ] {} test_13.rmt2 (7f9b740d-015c-470e-8cc6-8ba33be0dc63): auto DB::StorageReplicatedMergeTree::processQueueEntry(ReplicatedMergeTreeQueue::SelectedEntryPtr)::(anonymous class)::operator()(LogEntryPtr &) const: Code: 86. DB::HTTPException: Received error from remote server http://146b4357c08d:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Ftest%2F01165%2Ftest_13%2Frmt%2Freplicas%2F1&part=20250728_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.6.10636.altinitytest (altinity build)) '. (RECEIVED_ERROR_FROM_REMOTE_IO_SERVER), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.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 const&, int&&, String const&, unsigned long&&, String const&) @ 0x000000000feda8d9 4. /build/src/IO/HTTPCommon.cpp:104: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x000000000feda6e2 5. /build/src/IO/HTTPCommon.cpp:93: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x000000000feda537 6. /build/src/IO/ReadWriteBufferFromHTTP.cpp:277: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x000000001184a4c4 7. /build/src/IO/ReadWriteBufferFromHTTP.cpp:285: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x000000001184a615 8. /build/src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x000000001184ae59 9. /build/src/IO/ReadWriteBufferFromHTTP.cpp:472: void std::__function::__policy_invoker::__call_impl[abi:se190107]>(std::__function::__policy_storage const*) @ 0x000000001184cedd 10. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001184858b 11. /build/src/IO/ReadWriteBufferFromHTTP.cpp:465: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x000000001184bf0b 12. /build/src/IO/ReadBuffer.h:60: DB::ReadBuffer::next() @ 0x000000000a148c7b 13. /build/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) @ 0x0000000011849fb2 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]>&)>&, 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&) @ 0x0000000011841980 15. /build/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) @ 0x000000001621208e 16. /build/src/Storages/StorageReplicatedMergeTree.cpp:5228: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl[abi:se190107] const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000015f9a5fe 17. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000015ed8bfd 18. /build/src/Storages/StorageReplicatedMergeTree.cpp:2514: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x0000000015ec9aab 19. /build/src/Storages/StorageReplicatedMergeTree.cpp:2349: DB::StorageReplicatedMergeTree::executeLogEntry(DB::ReplicatedMergeTreeLogEntry&) @ 0x0000000015eba91b 20. /build/src/Storages/StorageReplicatedMergeTree.cpp:3876: bool std::__function::__policy_invoker&)>::__call_impl[abi:se190107])::$_1, bool (std::shared_ptr&)>>(std::__function::__policy_storage const*, std::shared_ptr&) @ 0x0000000015f9837e 21. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000165d6fc3 22. /build/src/Storages/StorageReplicatedMergeTree.cpp:3872: DB::StorageReplicatedMergeTree::processQueueEntry(std::shared_ptr) @ 0x0000000015efc18a 23. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001624c1b2 24. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000162f9c70 25. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x00000000162fa55a 26. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc6653 27. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000000fccc4c3 28. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc3d92 29. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fcca080 30. ? @ 0x00007fbc6213eac3 31. ? @ 0x00007fbc621d0850 (version 25.3.6.10636.altinitytest (altinity build)) 2025.07.28 12:01:33.982942 [ 3961 ] {} test_13.rmt2 (7f9b740d-015c-470e-8cc6-8ba33be0dc63): auto DB::StorageReplicatedMergeTree::processQueueEntry(ReplicatedMergeTreeQueue::SelectedEntryPtr)::(anonymous class)::operator()(LogEntryPtr &) const: Code: 86. DB::HTTPException: Received error from remote server http://146b4357c08d:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Ftest%2F01165%2Ftest_13%2Frmt%2Freplicas%2F1&part=20250728_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.6.10636.altinitytest (altinity build)) '. (RECEIVED_ERROR_FROM_REMOTE_IO_SERVER), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.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 const&, int&&, String const&, unsigned long&&, String const&) @ 0x000000000feda8d9 4. /build/src/IO/HTTPCommon.cpp:104: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x000000000feda6e2 5. /build/src/IO/HTTPCommon.cpp:93: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x000000000feda537 6. /build/src/IO/ReadWriteBufferFromHTTP.cpp:277: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x000000001184a4c4 7. /build/src/IO/ReadWriteBufferFromHTTP.cpp:285: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x000000001184a615 8. /build/src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x000000001184ae59 9. /build/src/IO/ReadWriteBufferFromHTTP.cpp:472: void std::__function::__policy_invoker::__call_impl[abi:se190107]>(std::__function::__policy_storage const*) @ 0x000000001184cedd 10. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001184858b 11. /build/src/IO/ReadWriteBufferFromHTTP.cpp:465: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x000000001184bf0b 12. /build/src/IO/ReadBuffer.h:60: DB::ReadBuffer::next() @ 0x000000000a148c7b 13. /build/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) @ 0x0000000011849fb2 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]>&)>&, 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&) @ 0x0000000011841980 15. /build/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) @ 0x000000001621208e 16. /build/src/Storages/StorageReplicatedMergeTree.cpp:5228: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl[abi:se190107] const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000015f9a5fe 17. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000015ed8bfd 18. /build/src/Storages/StorageReplicatedMergeTree.cpp:2514: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x0000000015ec9aab 19. /build/src/Storages/StorageReplicatedMergeTree.cpp:2349: DB::StorageReplicatedMergeTree::executeLogEntry(DB::ReplicatedMergeTreeLogEntry&) @ 0x0000000015eba91b 20. /build/src/Storages/StorageReplicatedMergeTree.cpp:3876: bool std::__function::__policy_invoker&)>::__call_impl[abi:se190107])::$_1, bool (std::shared_ptr&)>>(std::__function::__policy_storage const*, std::shared_ptr&) @ 0x0000000015f9837e 21. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000165d6fc3 22. /build/src/Storages/StorageReplicatedMergeTree.cpp:3872: DB::StorageReplicatedMergeTree::processQueueEntry(std::shared_ptr) @ 0x0000000015efc18a 23. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001624c1b2 24. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000162f9c70 25. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x00000000162fa55a 26. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc6653 27. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000000fccc4c3 28. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc3d92 29. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fcca080 30. ? @ 0x00007fbc6213eac3 31. ? @ 0x00007fbc621d0850 (version 25.3.6.10636.altinitytest (altinity build)) 2025.07.28 12:01:34.268231 [ 3977 ] {} test_13.rmt2 (7f9b740d-015c-470e-8cc6-8ba33be0dc63): auto DB::StorageReplicatedMergeTree::processQueueEntry(ReplicatedMergeTreeQueue::SelectedEntryPtr)::(anonymous class)::operator()(LogEntryPtr &) const: Code: 86. DB::HTTPException: Received error from remote server http://146b4357c08d:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Ftest%2F01165%2Ftest_13%2Frmt%2Freplicas%2F1&part=20250728_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.6.10636.altinitytest (altinity build)) '. (RECEIVED_ERROR_FROM_REMOTE_IO_SERVER), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.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 const&, int&&, String const&, unsigned long&&, String const&) @ 0x000000000feda8d9 4. /build/src/IO/HTTPCommon.cpp:104: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x000000000feda6e2 5. /build/src/IO/HTTPCommon.cpp:93: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x000000000feda537 6. /build/src/IO/ReadWriteBufferFromHTTP.cpp:277: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x000000001184a4c4 7. /build/src/IO/ReadWriteBufferFromHTTP.cpp:285: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x000000001184a615 8. /build/src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x000000001184ae59 9. /build/src/IO/ReadWriteBufferFromHTTP.cpp:472: void std::__function::__policy_invoker::__call_impl[abi:se190107]>(std::__function::__policy_storage const*) @ 0x000000001184cedd 10. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001184858b 11. /build/src/IO/ReadWriteBufferFromHTTP.cpp:465: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x000000001184bf0b 12. /build/src/IO/ReadBuffer.h:60: DB::ReadBuffer::next() @ 0x000000000a148c7b 13. /build/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) @ 0x0000000011849fb2 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]>&)>&, 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&) @ 0x0000000011841980 15. /build/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) @ 0x000000001621208e 16. /build/src/Storages/StorageReplicatedMergeTree.cpp:5228: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl[abi:se190107] const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000015f9a5fe 17. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000015ed8bfd 18. /build/src/Storages/StorageReplicatedMergeTree.cpp:2514: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x0000000015ec9aab 19. /build/src/Storages/StorageReplicatedMergeTree.cpp:2349: DB::StorageReplicatedMergeTree::executeLogEntry(DB::ReplicatedMergeTreeLogEntry&) @ 0x0000000015eba91b 20. /build/src/Storages/StorageReplicatedMergeTree.cpp:3876: bool std::__function::__policy_invoker&)>::__call_impl[abi:se190107])::$_1, bool (std::shared_ptr&)>>(std::__function::__policy_storage const*, std::shared_ptr&) @ 0x0000000015f9837e 21. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000165d6fc3 22. /build/src/Storages/StorageReplicatedMergeTree.cpp:3872: DB::StorageReplicatedMergeTree::processQueueEntry(std::shared_ptr) @ 0x0000000015efc18a 23. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001624c1b2 24. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000162f9c70 25. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x00000000162fa55a 26. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc6653 27. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000000fccc4c3 28. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc3d92 29. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fcca080 30. ? @ 0x00007fbc6213eac3 31. ? @ 0x00007fbc621d0850 (version 25.3.6.10636.altinitytest (altinity build)) 2025.07.28 12:01:34.648561 [ 17252 ] {0710fd2c-4e9e-4fb6-8cde-1363a006302a} executeQuery: Code: 675. DB::Exception: Invalid IPv4 value: In scope SELECT accurateCast('test', 'IPv4'). (CANNOT_PARSE_IPV4) (version 25.3.6.10636.altinitytest (altinity build)) (from [::1]:39342) (comment: 01601_accurate_cast.sql) (query 57, line 65) (in query: select accurateCast('test', 'IPv4');), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000000a074fcb 4. /build/src/Functions/FunctionsCodingIP.h:277: COW::immutable_ptr DB::convertToIPv4<(DB::IPStringToNumExceptionMode)0, DB::ColumnVector>(COW::immutable_ptr, DB::PODArray, 63ul, 64ul> const*) @ 0x0000000012df6ee8 5. /build/src/Functions/FunctionsConversion.h:5991: bool DB::detail::FunctionCast::prepareImpl(std::shared_ptr const&, std::shared_ptr const&, bool) const::'lambda0'(auto const&)::operator()>(auto const&) 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 @ 0x0000000012df5faa 6. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: COW::immutable_ptr std::__function::__policy_invoker::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)>::__call_impl[abi:se190107] const&, std::shared_ptr const&, bool) const::'lambda0'(auto const&)::operator()>(auto 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) @ 0x0000000012df5e69 7. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000012ddcb1b 8. /build/src/Functions/IFunction.h:57: DB::IExecutableFunction::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000a08134a 9. /build/src/Functions/IFunction.cpp:351: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d93b02 10. /build/src/Functions/IFunction.cpp:177: DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d93698 11. /build/src/Functions/IFunction.cpp:343: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d93aad 12. /build/src/Functions/IFunction.cpp:424: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d94e1b 13. /build/src/Functions/IFunction.cpp:498: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d95c72 14. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3567: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000014034494 15. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3838: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000014019a9e 16. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3980: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000014018e31 17. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:4304: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000014042fa7 18. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5605: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000014013749 19. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000140127f9 20. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000014011fce 21. /build/src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000001406ce8a 22. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000014973b42 23. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000001497268d 24. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000014974d24 25. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001492924b 26. /build/src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88641 27. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 28. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 29. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 30. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 31. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 2025.07.28 12:01:34.654786 [ 17252 ] {} TCPHandler: Code: 675. DB::Exception: Invalid IPv4 value: In scope SELECT accurateCast('test', 'IPv4'). (CANNOT_PARSE_IPV4), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000000a074fcb 4. /build/src/Functions/FunctionsCodingIP.h:277: COW::immutable_ptr DB::convertToIPv4<(DB::IPStringToNumExceptionMode)0, DB::ColumnVector>(COW::immutable_ptr, DB::PODArray, 63ul, 64ul> const*) @ 0x0000000012df6ee8 5. /build/src/Functions/FunctionsConversion.h:5991: bool DB::detail::FunctionCast::prepareImpl(std::shared_ptr const&, std::shared_ptr const&, bool) const::'lambda0'(auto const&)::operator()>(auto const&) 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 @ 0x0000000012df5faa 6. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: COW::immutable_ptr std::__function::__policy_invoker::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)>::__call_impl[abi:se190107] const&, std::shared_ptr const&, bool) const::'lambda0'(auto const&)::operator()>(auto 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) @ 0x0000000012df5e69 7. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000012ddcb1b 8. /build/src/Functions/IFunction.h:57: DB::IExecutableFunction::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000a08134a 9. /build/src/Functions/IFunction.cpp:351: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d93b02 10. /build/src/Functions/IFunction.cpp:177: DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d93698 11. /build/src/Functions/IFunction.cpp:343: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d93aad 12. /build/src/Functions/IFunction.cpp:424: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d94e1b 13. /build/src/Functions/IFunction.cpp:498: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d95c72 14. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3567: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000014034494 15. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3838: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000014019a9e 16. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3980: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000014018e31 17. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:4304: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000014042fa7 18. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5605: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000014013749 19. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000140127f9 20. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000014011fce 21. /build/src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000001406ce8a 22. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000014973b42 23. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000001497268d 24. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000014974d24 25. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001492924b 26. /build/src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88641 27. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 28. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 29. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 30. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 31. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 2025.07.28 12:01:34.733263 [ 17252 ] {29119402-a52b-437d-b6c9-3d352bb02b3d} executeQuery: Code: 675. DB::Exception: Invalid IPv4 value: In scope SELECT accurateCast('2001:db8::1', 'IPv4'). (CANNOT_PARSE_IPV4) (version 25.3.6.10636.altinitytest (altinity build)) (from [::1]:39342) (comment: 01601_accurate_cast.sql) (query 58, line 66) (in query: select accurateCast('2001:db8::1', 'IPv4');), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000000a074fcb 4. /build/src/Functions/FunctionsCodingIP.h:277: COW::immutable_ptr DB::convertToIPv4<(DB::IPStringToNumExceptionMode)0, DB::ColumnVector>(COW::immutable_ptr, DB::PODArray, 63ul, 64ul> const*) @ 0x0000000012df6ee8 5. /build/src/Functions/FunctionsConversion.h:5991: bool DB::detail::FunctionCast::prepareImpl(std::shared_ptr const&, std::shared_ptr const&, bool) const::'lambda0'(auto const&)::operator()>(auto const&) 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 @ 0x0000000012df5faa 6. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: COW::immutable_ptr std::__function::__policy_invoker::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)>::__call_impl[abi:se190107] const&, std::shared_ptr const&, bool) const::'lambda0'(auto const&)::operator()>(auto 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) @ 0x0000000012df5e69 7. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000012ddcb1b 8. /build/src/Functions/IFunction.h:57: DB::IExecutableFunction::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000a08134a 9. /build/src/Functions/IFunction.cpp:351: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d93b02 10. /build/src/Functions/IFunction.cpp:177: DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d93698 11. /build/src/Functions/IFunction.cpp:343: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d93aad 12. /build/src/Functions/IFunction.cpp:424: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d94e1b 13. /build/src/Functions/IFunction.cpp:498: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d95c72 14. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3567: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000014034494 15. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3838: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000014019a9e 16. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3980: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000014018e31 17. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:4304: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000014042fa7 18. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5605: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000014013749 19. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000140127f9 20. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000014011fce 21. /build/src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000001406ce8a 22. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000014973b42 23. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000001497268d 24. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000014974d24 25. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001492924b 26. /build/src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88641 27. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 28. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 29. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 30. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 31. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 2025.07.28 12:01:34.824361 [ 17252 ] {} TCPHandler: Code: 675. DB::Exception: Invalid IPv4 value: In scope SELECT accurateCast('2001:db8::1', 'IPv4'). (CANNOT_PARSE_IPV4), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000000a074fcb 4. /build/src/Functions/FunctionsCodingIP.h:277: COW::immutable_ptr DB::convertToIPv4<(DB::IPStringToNumExceptionMode)0, DB::ColumnVector>(COW::immutable_ptr, DB::PODArray, 63ul, 64ul> const*) @ 0x0000000012df6ee8 5. /build/src/Functions/FunctionsConversion.h:5991: bool DB::detail::FunctionCast::prepareImpl(std::shared_ptr const&, std::shared_ptr const&, bool) const::'lambda0'(auto const&)::operator()>(auto const&) 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 @ 0x0000000012df5faa 6. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: COW::immutable_ptr std::__function::__policy_invoker::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)>::__call_impl[abi:se190107] const&, std::shared_ptr const&, bool) const::'lambda0'(auto const&)::operator()>(auto 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) @ 0x0000000012df5e69 7. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000012ddcb1b 8. /build/src/Functions/IFunction.h:57: DB::IExecutableFunction::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000a08134a 9. /build/src/Functions/IFunction.cpp:351: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d93b02 10. /build/src/Functions/IFunction.cpp:177: DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d93698 11. /build/src/Functions/IFunction.cpp:343: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d93aad 12. /build/src/Functions/IFunction.cpp:424: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d94e1b 13. /build/src/Functions/IFunction.cpp:498: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d95c72 14. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3567: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000014034494 15. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3838: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000014019a9e 16. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3980: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000014018e31 17. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:4304: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000014042fa7 18. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5605: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000014013749 19. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000140127f9 20. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000014011fce 21. /build/src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000001406ce8a 22. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000014973b42 23. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000001497268d 24. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000014974d24 25. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001492924b 26. /build/src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88641 27. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 28. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 29. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 30. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 31. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 2025.07.28 12:01:34.883016 [ 17252 ] {3db46054-3aba-4257-9dee-416c6624f757} executeQuery: Code: 675. DB::Exception: Invalid IPv4 value: In scope SELECT accurateCast('::ffff:192.0.2.1', 'IPv4'). (CANNOT_PARSE_IPV4) (version 25.3.6.10636.altinitytest (altinity build)) (from [::1]:39342) (comment: 01601_accurate_cast.sql) (query 59, line 67) (in query: select accurateCast('::ffff:192.0.2.1', 'IPv4');), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000000a074fcb 4. /build/src/Functions/FunctionsCodingIP.h:277: COW::immutable_ptr DB::convertToIPv4<(DB::IPStringToNumExceptionMode)0, DB::ColumnVector>(COW::immutable_ptr, DB::PODArray, 63ul, 64ul> const*) @ 0x0000000012df6ee8 5. /build/src/Functions/FunctionsConversion.h:5991: bool DB::detail::FunctionCast::prepareImpl(std::shared_ptr const&, std::shared_ptr const&, bool) const::'lambda0'(auto const&)::operator()>(auto const&) 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 @ 0x0000000012df5faa 6. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: COW::immutable_ptr std::__function::__policy_invoker::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)>::__call_impl[abi:se190107] const&, std::shared_ptr const&, bool) const::'lambda0'(auto const&)::operator()>(auto 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) @ 0x0000000012df5e69 7. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000012ddcb1b 8. /build/src/Functions/IFunction.h:57: DB::IExecutableFunction::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000a08134a 9. /build/src/Functions/IFunction.cpp:351: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d93b02 10. /build/src/Functions/IFunction.cpp:177: DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d93698 11. /build/src/Functions/IFunction.cpp:343: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d93aad 12. /build/src/Functions/IFunction.cpp:424: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d94e1b 13. /build/src/Functions/IFunction.cpp:498: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d95c72 14. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3567: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000014034494 15. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3838: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000014019a9e 16. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3980: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000014018e31 17. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:4304: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000014042fa7 18. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5605: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000014013749 19. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000140127f9 20. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000014011fce 21. /build/src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000001406ce8a 22. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000014973b42 23. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000001497268d 24. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000014974d24 25. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001492924b 26. /build/src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88641 27. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 28. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 29. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 30. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 31. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 2025.07.28 12:01:34.886737 [ 17252 ] {} TCPHandler: Code: 675. DB::Exception: Invalid IPv4 value: In scope SELECT accurateCast('::ffff:192.0.2.1', 'IPv4'). (CANNOT_PARSE_IPV4), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000000a074fcb 4. /build/src/Functions/FunctionsCodingIP.h:277: COW::immutable_ptr DB::convertToIPv4<(DB::IPStringToNumExceptionMode)0, DB::ColumnVector>(COW::immutable_ptr, DB::PODArray, 63ul, 64ul> const*) @ 0x0000000012df6ee8 5. /build/src/Functions/FunctionsConversion.h:5991: bool DB::detail::FunctionCast::prepareImpl(std::shared_ptr const&, std::shared_ptr const&, bool) const::'lambda0'(auto const&)::operator()>(auto const&) 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 @ 0x0000000012df5faa 6. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: COW::immutable_ptr std::__function::__policy_invoker::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)>::__call_impl[abi:se190107] const&, std::shared_ptr const&, bool) const::'lambda0'(auto const&)::operator()>(auto 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) @ 0x0000000012df5e69 7. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000012ddcb1b 8. /build/src/Functions/IFunction.h:57: DB::IExecutableFunction::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000a08134a 9. /build/src/Functions/IFunction.cpp:351: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d93b02 10. /build/src/Functions/IFunction.cpp:177: DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d93698 11. /build/src/Functions/IFunction.cpp:343: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d93aad 12. /build/src/Functions/IFunction.cpp:424: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d94e1b 13. /build/src/Functions/IFunction.cpp:498: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d95c72 14. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3567: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000014034494 15. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3838: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000014019a9e 16. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3980: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000014018e31 17. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:4304: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000014042fa7 18. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5605: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000014013749 19. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000140127f9 20. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000014011fce 21. /build/src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000001406ce8a 22. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000014973b42 23. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000001497268d 24. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000014974d24 25. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001492924b 26. /build/src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88641 27. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 28. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 29. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 30. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 31. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 2025.07.28 12:01:34.952375 [ 3974 ] {} test_13.rmt2 (7f9b740d-015c-470e-8cc6-8ba33be0dc63): auto DB::StorageReplicatedMergeTree::processQueueEntry(ReplicatedMergeTreeQueue::SelectedEntryPtr)::(anonymous class)::operator()(LogEntryPtr &) const: Code: 86. DB::HTTPException: Received error from remote server http://146b4357c08d:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Ftest%2F01165%2Ftest_13%2Frmt%2Freplicas%2F1&part=20250728_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.6.10636.altinitytest (altinity build)) '. (RECEIVED_ERROR_FROM_REMOTE_IO_SERVER), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.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 const&, int&&, String const&, unsigned long&&, String const&) @ 0x000000000feda8d9 4. /build/src/IO/HTTPCommon.cpp:104: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x000000000feda6e2 5. /build/src/IO/HTTPCommon.cpp:93: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x000000000feda537 6. /build/src/IO/ReadWriteBufferFromHTTP.cpp:277: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x000000001184a4c4 7. /build/src/IO/ReadWriteBufferFromHTTP.cpp:285: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x000000001184a615 8. /build/src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x000000001184ae59 9. /build/src/IO/ReadWriteBufferFromHTTP.cpp:472: void std::__function::__policy_invoker::__call_impl[abi:se190107]>(std::__function::__policy_storage const*) @ 0x000000001184cedd 10. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001184858b 11. /build/src/IO/ReadWriteBufferFromHTTP.cpp:465: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x000000001184bf0b 12. /build/src/IO/ReadBuffer.h:60: DB::ReadBuffer::next() @ 0x000000000a148c7b 13. /build/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) @ 0x0000000011849fb2 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]>&)>&, 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&) @ 0x0000000011841980 15. /build/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) @ 0x000000001621208e 16. /build/src/Storages/StorageReplicatedMergeTree.cpp:5228: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl[abi:se190107] const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000015f9a5fe 17. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000015ed8bfd 18. /build/src/Storages/StorageReplicatedMergeTree.cpp:2514: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x0000000015ec9aab 19. /build/src/Storages/StorageReplicatedMergeTree.cpp:2349: DB::StorageReplicatedMergeTree::executeLogEntry(DB::ReplicatedMergeTreeLogEntry&) @ 0x0000000015eba91b 20. /build/src/Storages/StorageReplicatedMergeTree.cpp:3876: bool std::__function::__policy_invoker&)>::__call_impl[abi:se190107])::$_1, bool (std::shared_ptr&)>>(std::__function::__policy_storage const*, std::shared_ptr&) @ 0x0000000015f9837e 21. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000165d6fc3 22. /build/src/Storages/StorageReplicatedMergeTree.cpp:3872: DB::StorageReplicatedMergeTree::processQueueEntry(std::shared_ptr) @ 0x0000000015efc18a 23. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001624c1b2 24. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000162f9c70 25. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x00000000162fa55a 26. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc6653 27. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000000fccc4c3 28. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc3d92 29. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fcca080 30. ? @ 0x00007fbc6213eac3 31. ? @ 0x00007fbc621d0850 (version 25.3.6.10636.altinitytest (altinity build)) 2025.07.28 12:01:35.014118 [ 17252 ] {c1aa38d4-2e27-48c7-9150-417e823902e9} executeQuery: Code: 675. DB::Exception: Invalid IPv4 value: In scope SELECT accurateCast('192.0.2.1x', 'IPv4'). (CANNOT_PARSE_IPV4) (version 25.3.6.10636.altinitytest (altinity build)) (from [::1]:39342) (comment: 01601_accurate_cast.sql) (query 61, line 69) (in query: select accurateCast('192.0.2.1x', 'IPv4');), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000000a074fcb 4. /build/src/Functions/FunctionsCodingIP.h:277: COW::immutable_ptr DB::convertToIPv4<(DB::IPStringToNumExceptionMode)0, DB::ColumnVector>(COW::immutable_ptr, DB::PODArray, 63ul, 64ul> const*) @ 0x0000000012df6ee8 5. /build/src/Functions/FunctionsConversion.h:5991: bool DB::detail::FunctionCast::prepareImpl(std::shared_ptr const&, std::shared_ptr const&, bool) const::'lambda0'(auto const&)::operator()>(auto const&) 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 @ 0x0000000012df5faa 6. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: COW::immutable_ptr std::__function::__policy_invoker::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)>::__call_impl[abi:se190107] const&, std::shared_ptr const&, bool) const::'lambda0'(auto const&)::operator()>(auto 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) @ 0x0000000012df5e69 7. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000012ddcb1b 8. /build/src/Functions/IFunction.h:57: DB::IExecutableFunction::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000a08134a 9. /build/src/Functions/IFunction.cpp:351: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d93b02 10. /build/src/Functions/IFunction.cpp:177: DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d93698 11. /build/src/Functions/IFunction.cpp:343: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d93aad 12. /build/src/Functions/IFunction.cpp:424: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d94e1b 13. /build/src/Functions/IFunction.cpp:498: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d95c72 14. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3567: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000014034494 15. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3838: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000014019a9e 16. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3980: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000014018e31 17. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:4304: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000014042fa7 18. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5605: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000014013749 19. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000140127f9 20. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000014011fce 21. /build/src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000001406ce8a 22. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000014973b42 23. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000001497268d 24. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000014974d24 25. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001492924b 26. /build/src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88641 27. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 28. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 29. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 30. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 31. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 2025.07.28 12:01:35.021737 [ 17252 ] {} TCPHandler: Code: 675. DB::Exception: Invalid IPv4 value: In scope SELECT accurateCast('192.0.2.1x', 'IPv4'). (CANNOT_PARSE_IPV4), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000000a074fcb 4. /build/src/Functions/FunctionsCodingIP.h:277: COW::immutable_ptr DB::convertToIPv4<(DB::IPStringToNumExceptionMode)0, DB::ColumnVector>(COW::immutable_ptr, DB::PODArray, 63ul, 64ul> const*) @ 0x0000000012df6ee8 5. /build/src/Functions/FunctionsConversion.h:5991: bool DB::detail::FunctionCast::prepareImpl(std::shared_ptr const&, std::shared_ptr const&, bool) const::'lambda0'(auto const&)::operator()>(auto const&) 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 @ 0x0000000012df5faa 6. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: COW::immutable_ptr std::__function::__policy_invoker::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)>::__call_impl[abi:se190107] const&, std::shared_ptr const&, bool) const::'lambda0'(auto const&)::operator()>(auto 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) @ 0x0000000012df5e69 7. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000012ddcb1b 8. /build/src/Functions/IFunction.h:57: DB::IExecutableFunction::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000a08134a 9. /build/src/Functions/IFunction.cpp:351: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d93b02 10. /build/src/Functions/IFunction.cpp:177: DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d93698 11. /build/src/Functions/IFunction.cpp:343: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d93aad 12. /build/src/Functions/IFunction.cpp:424: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d94e1b 13. /build/src/Functions/IFunction.cpp:498: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d95c72 14. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3567: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000014034494 15. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3838: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000014019a9e 16. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3980: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000014018e31 17. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:4304: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000014042fa7 18. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5605: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000014013749 19. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000140127f9 20. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000014011fce 21. /build/src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000001406ce8a 22. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000014973b42 23. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000001497268d 24. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000014974d24 25. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001492924b 26. /build/src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88641 27. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 28. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 29. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 30. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 31. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 2025.07.28 12:01:35.186596 [ 17252 ] {af59d850-8d07-4145-982b-3be3c4314e7b} executeQuery: Code: 676. DB::Exception: Invalid IPv6 value: In scope SELECT accurateCast('test', 'IPv6'). (CANNOT_PARSE_IPV6) (version 25.3.6.10636.altinitytest (altinity build)) (from [::1]:39342) (comment: 01601_accurate_cast.sql) (query 63, line 72) (in query: select accurateCast('test', 'IPv6');), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000000a074fcb 4. /build/src/Functions/FunctionsCodingIP.h:198: COW::immutable_ptr DB::detail::convertToIPv6<(DB::IPStringToNumExceptionMode)0, DB::ColumnVector, DB::ColumnString>(DB::ColumnString const&, DB::PODArray, 63ul, 64ul> const*) @ 0x0000000012df947b 5. /build/src/Functions/FunctionsCodingIP.h:220: COW::immutable_ptr DB::convertToIPv6<(DB::IPStringToNumExceptionMode)0, DB::ColumnVector>(COW::immutable_ptr, DB::PODArray, 63ul, 64ul> const*) @ 0x0000000012df7810 6. /build/src/Functions/FunctionsConversion.h:6017: bool DB::detail::FunctionCast::prepareImpl(std::shared_ptr const&, std::shared_ptr const&, bool) const::'lambda0'(auto const&)::operator()>(auto const&) 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 @ 0x0000000012df72ca 7. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: COW::immutable_ptr std::__function::__policy_invoker::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)>::__call_impl[abi:se190107] const&, std::shared_ptr const&, bool) const::'lambda0'(auto const&)::operator()>(auto 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) @ 0x0000000012df7189 8. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000012ddcb1b 9. /build/src/Functions/IFunction.h:57: DB::IExecutableFunction::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000a08134a 10. /build/src/Functions/IFunction.cpp:351: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d93b02 11. /build/src/Functions/IFunction.cpp:177: DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d93698 12. /build/src/Functions/IFunction.cpp:343: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d93aad 13. /build/src/Functions/IFunction.cpp:424: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d94e1b 14. /build/src/Functions/IFunction.cpp:498: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d95c72 15. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3567: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000014034494 16. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3838: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000014019a9e 17. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3980: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000014018e31 18. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:4304: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000014042fa7 19. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5605: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000014013749 20. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000140127f9 21. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000014011fce 22. /build/src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000001406ce8a 23. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000014973b42 24. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000001497268d 25. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000014974d24 26. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001492924b 27. /build/src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88641 28. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 29. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 30. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 31. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 2025.07.28 12:01:35.189508 [ 17252 ] {} TCPHandler: Code: 676. DB::Exception: Invalid IPv6 value: In scope SELECT accurateCast('test', 'IPv6'). (CANNOT_PARSE_IPV6), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000000a074fcb 4. /build/src/Functions/FunctionsCodingIP.h:198: COW::immutable_ptr DB::detail::convertToIPv6<(DB::IPStringToNumExceptionMode)0, DB::ColumnVector, DB::ColumnString>(DB::ColumnString const&, DB::PODArray, 63ul, 64ul> const*) @ 0x0000000012df947b 5. /build/src/Functions/FunctionsCodingIP.h:220: COW::immutable_ptr DB::convertToIPv6<(DB::IPStringToNumExceptionMode)0, DB::ColumnVector>(COW::immutable_ptr, DB::PODArray, 63ul, 64ul> const*) @ 0x0000000012df7810 6. /build/src/Functions/FunctionsConversion.h:6017: bool DB::detail::FunctionCast::prepareImpl(std::shared_ptr const&, std::shared_ptr const&, bool) const::'lambda0'(auto const&)::operator()>(auto const&) 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 @ 0x0000000012df72ca 7. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: COW::immutable_ptr std::__function::__policy_invoker::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)>::__call_impl[abi:se190107] const&, std::shared_ptr const&, bool) const::'lambda0'(auto const&)::operator()>(auto 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) @ 0x0000000012df7189 8. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000012ddcb1b 9. /build/src/Functions/IFunction.h:57: DB::IExecutableFunction::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000a08134a 10. /build/src/Functions/IFunction.cpp:351: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d93b02 11. /build/src/Functions/IFunction.cpp:177: DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d93698 12. /build/src/Functions/IFunction.cpp:343: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d93aad 13. /build/src/Functions/IFunction.cpp:424: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d94e1b 14. /build/src/Functions/IFunction.cpp:498: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d95c72 15. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3567: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000014034494 16. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3838: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000014019a9e 17. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3980: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000014018e31 18. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:4304: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000014042fa7 19. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5605: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000014013749 20. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000140127f9 21. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000014011fce 22. /build/src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000001406ce8a 23. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000014973b42 24. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000001497268d 25. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000014974d24 26. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001492924b 27. /build/src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88641 28. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 29. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 30. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 31. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 2025.07.28 12:01:35.316655 [ 17252 ] {9be6de01-0528-492f-afbd-9d3a8f800d37} executeQuery: Code: 676. DB::Exception: Invalid IPv6 value: In scope SELECT accurateCast('2001:db8::1x', 'IPv6'). (CANNOT_PARSE_IPV6) (version 25.3.6.10636.altinitytest (altinity build)) (from [::1]:39342) (comment: 01601_accurate_cast.sql) (query 66, line 75) (in query: select accurateCast('2001:db8::1x', 'IPv6');), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000000a074fcb 4. /build/src/Functions/FunctionsCodingIP.h:198: COW::immutable_ptr DB::detail::convertToIPv6<(DB::IPStringToNumExceptionMode)0, DB::ColumnVector, DB::ColumnString>(DB::ColumnString const&, DB::PODArray, 63ul, 64ul> const*) @ 0x0000000012df947b 5. /build/src/Functions/FunctionsCodingIP.h:220: COW::immutable_ptr DB::convertToIPv6<(DB::IPStringToNumExceptionMode)0, DB::ColumnVector>(COW::immutable_ptr, DB::PODArray, 63ul, 64ul> const*) @ 0x0000000012df7810 6. /build/src/Functions/FunctionsConversion.h:6017: bool DB::detail::FunctionCast::prepareImpl(std::shared_ptr const&, std::shared_ptr const&, bool) const::'lambda0'(auto const&)::operator()>(auto const&) 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 @ 0x0000000012df72ca 7. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: COW::immutable_ptr std::__function::__policy_invoker::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)>::__call_impl[abi:se190107] const&, std::shared_ptr const&, bool) const::'lambda0'(auto const&)::operator()>(auto 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) @ 0x0000000012df7189 8. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000012ddcb1b 9. /build/src/Functions/IFunction.h:57: DB::IExecutableFunction::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000a08134a 10. /build/src/Functions/IFunction.cpp:351: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d93b02 11. /build/src/Functions/IFunction.cpp:177: DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d93698 12. /build/src/Functions/IFunction.cpp:343: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d93aad 13. /build/src/Functions/IFunction.cpp:424: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d94e1b 14. /build/src/Functions/IFunction.cpp:498: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d95c72 15. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3567: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000014034494 16. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3838: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000014019a9e 17. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3980: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000014018e31 18. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:4304: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000014042fa7 19. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5605: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000014013749 20. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000140127f9 21. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000014011fce 22. /build/src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000001406ce8a 23. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000014973b42 24. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000001497268d 25. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000014974d24 26. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001492924b 27. /build/src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88641 28. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 29. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 30. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 31. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 2025.07.28 12:01:35.320106 [ 17252 ] {} TCPHandler: Code: 676. DB::Exception: Invalid IPv6 value: In scope SELECT accurateCast('2001:db8::1x', 'IPv6'). (CANNOT_PARSE_IPV6), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000000a074fcb 4. /build/src/Functions/FunctionsCodingIP.h:198: COW::immutable_ptr DB::detail::convertToIPv6<(DB::IPStringToNumExceptionMode)0, DB::ColumnVector, DB::ColumnString>(DB::ColumnString const&, DB::PODArray, 63ul, 64ul> const*) @ 0x0000000012df947b 5. /build/src/Functions/FunctionsCodingIP.h:220: COW::immutable_ptr DB::convertToIPv6<(DB::IPStringToNumExceptionMode)0, DB::ColumnVector>(COW::immutable_ptr, DB::PODArray, 63ul, 64ul> const*) @ 0x0000000012df7810 6. /build/src/Functions/FunctionsConversion.h:6017: bool DB::detail::FunctionCast::prepareImpl(std::shared_ptr const&, std::shared_ptr const&, bool) const::'lambda0'(auto const&)::operator()>(auto const&) 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 @ 0x0000000012df72ca 7. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: COW::immutable_ptr std::__function::__policy_invoker::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)>::__call_impl[abi:se190107] const&, std::shared_ptr const&, bool) const::'lambda0'(auto const&)::operator()>(auto 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) @ 0x0000000012df7189 8. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000012ddcb1b 9. /build/src/Functions/IFunction.h:57: DB::IExecutableFunction::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000a08134a 10. /build/src/Functions/IFunction.cpp:351: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d93b02 11. /build/src/Functions/IFunction.cpp:177: DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d93698 12. /build/src/Functions/IFunction.cpp:343: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d93aad 13. /build/src/Functions/IFunction.cpp:424: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d94e1b 14. /build/src/Functions/IFunction.cpp:498: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d95c72 15. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3567: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000014034494 16. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3838: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000014019a9e 17. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3980: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000014018e31 18. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:4304: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000014042fa7 19. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5605: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000014013749 20. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000140127f9 21. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000014011fce 22. /build/src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000001406ce8a 23. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000014973b42 24. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000001497268d 25. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000014974d24 26. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001492924b 27. /build/src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88641 28. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 29. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 30. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 31. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 2025.07.28 12:01:35.400565 [ 3971 ] {} test_13.rmt2 (7f9b740d-015c-470e-8cc6-8ba33be0dc63): auto DB::StorageReplicatedMergeTree::processQueueEntry(ReplicatedMergeTreeQueue::SelectedEntryPtr)::(anonymous class)::operator()(LogEntryPtr &) const: Code: 86. DB::HTTPException: Received error from remote server http://146b4357c08d:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Ftest%2F01165%2Ftest_13%2Frmt%2Freplicas%2F1&part=20250728_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.6.10636.altinitytest (altinity build)) '. (RECEIVED_ERROR_FROM_REMOTE_IO_SERVER), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.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 const&, int&&, String const&, unsigned long&&, String const&) @ 0x000000000feda8d9 4. /build/src/IO/HTTPCommon.cpp:104: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x000000000feda6e2 5. /build/src/IO/HTTPCommon.cpp:93: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x000000000feda537 6. /build/src/IO/ReadWriteBufferFromHTTP.cpp:277: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x000000001184a4c4 7. /build/src/IO/ReadWriteBufferFromHTTP.cpp:285: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x000000001184a615 8. /build/src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x000000001184ae59 9. /build/src/IO/ReadWriteBufferFromHTTP.cpp:472: void std::__function::__policy_invoker::__call_impl[abi:se190107]>(std::__function::__policy_storage const*) @ 0x000000001184cedd 10. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001184858b 11. /build/src/IO/ReadWriteBufferFromHTTP.cpp:465: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x000000001184bf0b 12. /build/src/IO/ReadBuffer.h:60: DB::ReadBuffer::next() @ 0x000000000a148c7b 13. /build/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) @ 0x0000000011849fb2 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]>&)>&, 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&) @ 0x0000000011841980 15. /build/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) @ 0x000000001621208e 16. /build/src/Storages/StorageReplicatedMergeTree.cpp:5228: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl[abi:se190107] const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000015f9a5fe 17. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000015ed8bfd 18. /build/src/Storages/StorageReplicatedMergeTree.cpp:2514: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x0000000015ec9aab 19. /build/src/Storages/StorageReplicatedMergeTree.cpp:2349: DB::StorageReplicatedMergeTree::executeLogEntry(DB::ReplicatedMergeTreeLogEntry&) @ 0x0000000015eba91b 20. /build/src/Storages/StorageReplicatedMergeTree.cpp:3876: bool std::__function::__policy_invoker&)>::__call_impl[abi:se190107])::$_1, bool (std::shared_ptr&)>>(std::__function::__policy_storage const*, std::shared_ptr&) @ 0x0000000015f9837e 21. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000165d6fc3 22. /build/src/Storages/StorageReplicatedMergeTree.cpp:3872: DB::StorageReplicatedMergeTree::processQueueEntry(std::shared_ptr) @ 0x0000000015efc18a 23. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001624c1b2 24. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000162f9c70 25. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x00000000162fa55a 26. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc6653 27. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000000fccc4c3 28. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc3d92 29. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fcca080 30. ? @ 0x00007fbc6213eac3 31. ? @ 0x00007fbc621d0850 (version 25.3.6.10636.altinitytest (altinity build)) 2025.07.28 12:01:36.296531 [ 3967 ] {} test_13.rmt2 (7f9b740d-015c-470e-8cc6-8ba33be0dc63): auto DB::StorageReplicatedMergeTree::processQueueEntry(ReplicatedMergeTreeQueue::SelectedEntryPtr)::(anonymous class)::operator()(LogEntryPtr &) const: Code: 86. DB::HTTPException: Received error from remote server http://146b4357c08d:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Ftest%2F01165%2Ftest_13%2Frmt%2Freplicas%2F1&part=20250728_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.6.10636.altinitytest (altinity build)) '. (RECEIVED_ERROR_FROM_REMOTE_IO_SERVER), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.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 const&, int&&, String const&, unsigned long&&, String const&) @ 0x000000000feda8d9 4. /build/src/IO/HTTPCommon.cpp:104: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x000000000feda6e2 5. /build/src/IO/HTTPCommon.cpp:93: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x000000000feda537 6. /build/src/IO/ReadWriteBufferFromHTTP.cpp:277: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x000000001184a4c4 7. /build/src/IO/ReadWriteBufferFromHTTP.cpp:285: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x000000001184a615 8. /build/src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x000000001184ae59 9. /build/src/IO/ReadWriteBufferFromHTTP.cpp:472: void std::__function::__policy_invoker::__call_impl[abi:se190107]>(std::__function::__policy_storage const*) @ 0x000000001184cedd 10. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001184858b 11. /build/src/IO/ReadWriteBufferFromHTTP.cpp:465: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x000000001184bf0b 12. /build/src/IO/ReadBuffer.h:60: DB::ReadBuffer::next() @ 0x000000000a148c7b 13. /build/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) @ 0x0000000011849fb2 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]>&)>&, 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&) @ 0x0000000011841980 15. /build/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) @ 0x000000001621208e 16. /build/src/Storages/StorageReplicatedMergeTree.cpp:5228: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl[abi:se190107] const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000015f9a5fe 17. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000015ed8bfd 18. /build/src/Storages/StorageReplicatedMergeTree.cpp:2514: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x0000000015ec9aab 19. /build/src/Storages/StorageReplicatedMergeTree.cpp:2349: DB::StorageReplicatedMergeTree::executeLogEntry(DB::ReplicatedMergeTreeLogEntry&) @ 0x0000000015eba91b 20. /build/src/Storages/StorageReplicatedMergeTree.cpp:3876: bool std::__function::__policy_invoker&)>::__call_impl[abi:se190107])::$_1, bool (std::shared_ptr&)>>(std::__function::__policy_storage const*, std::shared_ptr&) @ 0x0000000015f9837e 21. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000165d6fc3 22. /build/src/Storages/StorageReplicatedMergeTree.cpp:3872: DB::StorageReplicatedMergeTree::processQueueEntry(std::shared_ptr) @ 0x0000000015efc18a 23. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001624c1b2 24. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000162f9c70 25. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x00000000162fa55a 26. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc6653 27. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000000fccc4c3 28. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc3d92 29. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fcca080 30. ? @ 0x00007fbc6213eac3 31. ? @ 0x00007fbc621d0850 (version 25.3.6.10636.altinitytest (altinity build)) 2025.07.28 12:01:36.466622 [ 3970 ] {} test_13.rmt2 (7f9b740d-015c-470e-8cc6-8ba33be0dc63): auto DB::StorageReplicatedMergeTree::processQueueEntry(ReplicatedMergeTreeQueue::SelectedEntryPtr)::(anonymous class)::operator()(LogEntryPtr &) const: Code: 86. DB::HTTPException: Received error from remote server http://146b4357c08d:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Ftest%2F01165%2Ftest_13%2Frmt%2Freplicas%2F1&part=20250728_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.6.10636.altinitytest (altinity build)) '. (RECEIVED_ERROR_FROM_REMOTE_IO_SERVER), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.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 const&, int&&, String const&, unsigned long&&, String const&) @ 0x000000000feda8d9 4. /build/src/IO/HTTPCommon.cpp:104: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x000000000feda6e2 5. /build/src/IO/HTTPCommon.cpp:93: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x000000000feda537 6. /build/src/IO/ReadWriteBufferFromHTTP.cpp:277: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x000000001184a4c4 7. /build/src/IO/ReadWriteBufferFromHTTP.cpp:285: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x000000001184a615 8. /build/src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x000000001184ae59 9. /build/src/IO/ReadWriteBufferFromHTTP.cpp:472: void std::__function::__policy_invoker::__call_impl[abi:se190107]>(std::__function::__policy_storage const*) @ 0x000000001184cedd 10. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001184858b 11. /build/src/IO/ReadWriteBufferFromHTTP.cpp:465: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x000000001184bf0b 12. /build/src/IO/ReadBuffer.h:60: DB::ReadBuffer::next() @ 0x000000000a148c7b 13. /build/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) @ 0x0000000011849fb2 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]>&)>&, 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&) @ 0x0000000011841980 15. /build/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) @ 0x000000001621208e 16. /build/src/Storages/StorageReplicatedMergeTree.cpp:5228: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl[abi:se190107] const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000015f9a5fe 17. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000015ed8bfd 18. /build/src/Storages/StorageReplicatedMergeTree.cpp:2514: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x0000000015ec9aab 19. /build/src/Storages/StorageReplicatedMergeTree.cpp:2349: DB::StorageReplicatedMergeTree::executeLogEntry(DB::ReplicatedMergeTreeLogEntry&) @ 0x0000000015eba91b 20. /build/src/Storages/StorageReplicatedMergeTree.cpp:3876: bool std::__function::__policy_invoker&)>::__call_impl[abi:se190107])::$_1, bool (std::shared_ptr&)>>(std::__function::__policy_storage const*, std::shared_ptr&) @ 0x0000000015f9837e 21. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000165d6fc3 22. /build/src/Storages/StorageReplicatedMergeTree.cpp:3872: DB::StorageReplicatedMergeTree::processQueueEntry(std::shared_ptr) @ 0x0000000015efc18a 23. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001624c1b2 24. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000162f9c70 25. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x00000000162fa55a 26. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc6653 27. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000000fccc4c3 28. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc3d92 29. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fcca080 30. ? @ 0x00007fbc6213eac3 31. ? @ 0x00007fbc621d0850 (version 25.3.6.10636.altinitytest (altinity build)) 2025.07.28 12:01:36.927340 [ 3965 ] {} test_13.rmt2 (7f9b740d-015c-470e-8cc6-8ba33be0dc63): auto DB::StorageReplicatedMergeTree::processQueueEntry(ReplicatedMergeTreeQueue::SelectedEntryPtr)::(anonymous class)::operator()(LogEntryPtr &) const: Code: 86. DB::HTTPException: Received error from remote server http://146b4357c08d:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Ftest%2F01165%2Ftest_13%2Frmt%2Freplicas%2F1&part=20250728_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.6.10636.altinitytest (altinity build)) '. (RECEIVED_ERROR_FROM_REMOTE_IO_SERVER), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.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 const&, int&&, String const&, unsigned long&&, String const&) @ 0x000000000feda8d9 4. /build/src/IO/HTTPCommon.cpp:104: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x000000000feda6e2 5. /build/src/IO/HTTPCommon.cpp:93: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x000000000feda537 6. /build/src/IO/ReadWriteBufferFromHTTP.cpp:277: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x000000001184a4c4 7. /build/src/IO/ReadWriteBufferFromHTTP.cpp:285: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x000000001184a615 8. /build/src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x000000001184ae59 9. /build/src/IO/ReadWriteBufferFromHTTP.cpp:472: void std::__function::__policy_invoker::__call_impl[abi:se190107]>(std::__function::__policy_storage const*) @ 0x000000001184cedd 10. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001184858b 11. /build/src/IO/ReadWriteBufferFromHTTP.cpp:465: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x000000001184bf0b 12. /build/src/IO/ReadBuffer.h:60: DB::ReadBuffer::next() @ 0x000000000a148c7b 13. /build/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) @ 0x0000000011849fb2 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]>&)>&, 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&) @ 0x0000000011841980 15. /build/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) @ 0x000000001621208e 16. /build/src/Storages/StorageReplicatedMergeTree.cpp:5228: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl[abi:se190107] const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000015f9a5fe 17. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000015ed8bfd 18. /build/src/Storages/StorageReplicatedMergeTree.cpp:2514: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x0000000015ec9aab 19. /build/src/Storages/StorageReplicatedMergeTree.cpp:2349: DB::StorageReplicatedMergeTree::executeLogEntry(DB::ReplicatedMergeTreeLogEntry&) @ 0x0000000015eba91b 20. /build/src/Storages/StorageReplicatedMergeTree.cpp:3876: bool std::__function::__policy_invoker&)>::__call_impl[abi:se190107])::$_1, bool (std::shared_ptr&)>>(std::__function::__policy_storage const*, std::shared_ptr&) @ 0x0000000015f9837e 21. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000165d6fc3 22. /build/src/Storages/StorageReplicatedMergeTree.cpp:3872: DB::StorageReplicatedMergeTree::processQueueEntry(std::shared_ptr) @ 0x0000000015efc18a 23. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001624c1b2 24. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000162f9c70 25. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x00000000162fa55a 26. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc6653 27. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000000fccc4c3 28. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc3d92 29. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fcca080 30. ? @ 0x00007fbc6213eac3 31. ? @ 0x00007fbc621d0850 (version 25.3.6.10636.altinitytest (altinity build)) 2025.07.28 12:01:37.755100 [ 17243 ] {14490d6a-95e1-4cf5-933e-5b2185f6f464} executeQuery: Code: 42. DB::Exception: Number of arguments for function neighbor doesn't match: passed 0, should be from 2 to 3: In scope SELECT neighbor(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.6.10636.altinitytest (altinity build)) (from [::1]:44504) (comment: 00957_neighbor.sql) (query 2, line 2) (in query: -- no arguments select neighbor();), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, unsigned long&) @ 0x000000000a1f636b 4. /build/src/Functions/neighbor.cpp:83: DB::(anonymous namespace)::FunctionNeighbor::getReturnTypeImpl(std::vector, std::allocator>> const&) const @ 0x000000000db1eb0c 5. /build/src/Functions/IFunction.h:520: DB::IFunction::getReturnTypeImpl(std::vector> const&) const @ 0x000000000a06a2de 6. /build/src/Functions/IFunction.cpp:645: DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x0000000012d96b0c 7. /build/src/Functions/IFunction.cpp:585: DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x0000000012d9665b 8. /build/src/Functions/IFunction.cpp:606: DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x0000000012d96edc 9. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3544: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000014033cc9 10. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3838: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000014019a9e 11. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3980: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000014018e31 12. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:4304: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000014042fa7 13. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5605: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000014013749 14. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000140127f9 15. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000014011fce 16. /build/src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000001406ce8a 17. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000014973b42 18. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000001497268d 19. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000014974d24 20. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001492924b 21. /build/src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88641 22. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 23. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 24. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 25. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 26. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 27. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 28. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 29. ? @ 0x00007fbc6213eac3 30. ? @ 0x00007fbc621d0850 2025.07.28 12:01:37.766261 [ 17243 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function neighbor doesn't match: passed 0, should be from 2 to 3: In scope SELECT neighbor(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, unsigned long&) @ 0x000000000a1f636b 4. /build/src/Functions/neighbor.cpp:83: DB::(anonymous namespace)::FunctionNeighbor::getReturnTypeImpl(std::vector, std::allocator>> const&) const @ 0x000000000db1eb0c 5. /build/src/Functions/IFunction.h:520: DB::IFunction::getReturnTypeImpl(std::vector> const&) const @ 0x000000000a06a2de 6. /build/src/Functions/IFunction.cpp:645: DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x0000000012d96b0c 7. /build/src/Functions/IFunction.cpp:585: DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x0000000012d9665b 8. /build/src/Functions/IFunction.cpp:606: DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x0000000012d96edc 9. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3544: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000014033cc9 10. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3838: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000014019a9e 11. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3980: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000014018e31 12. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:4304: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000014042fa7 13. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5605: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000014013749 14. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000140127f9 15. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000014011fce 16. /build/src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000001406ce8a 17. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000014973b42 18. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000001497268d 19. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000014974d24 20. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001492924b 21. /build/src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88641 22. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 23. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 24. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 25. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 26. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 27. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 28. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 29. ? @ 0x00007fbc6213eac3 30. ? @ 0x00007fbc621d0850 2025.07.28 12:01:37.817977 [ 17243 ] {7de9f3dd-1a37-415e-8b6a-6f2b251d414f} executeQuery: Code: 42. DB::Exception: Number of arguments for function neighbor doesn't match: passed 1, should be from 2 to 3: In scope SELECT neighbor(1). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.6.10636.altinitytest (altinity build)) (from [::1]:44504) (comment: 00957_neighbor.sql) (query 3, line 4) (in query: -- single argument select neighbor(1);), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, unsigned long&) @ 0x000000000a1f636b 4. /build/src/Functions/neighbor.cpp:83: DB::(anonymous namespace)::FunctionNeighbor::getReturnTypeImpl(std::vector, std::allocator>> const&) const @ 0x000000000db1eb0c 5. /build/src/Functions/IFunction.h:520: DB::IFunction::getReturnTypeImpl(std::vector> const&) const @ 0x000000000a06a2de 6. /build/src/Functions/IFunction.cpp:645: DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x0000000012d96b0c 7. /build/src/Functions/IFunction.cpp:585: DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x0000000012d9665b 8. /build/src/Functions/IFunction.cpp:606: DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x0000000012d96edc 9. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3544: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000014033cc9 10. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3838: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000014019a9e 11. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3980: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000014018e31 12. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:4304: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000014042fa7 13. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5605: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000014013749 14. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000140127f9 15. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000014011fce 16. /build/src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000001406ce8a 17. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000014973b42 18. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000001497268d 19. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000014974d24 20. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001492924b 21. /build/src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88641 22. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 23. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 24. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 25. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 26. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 27. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 28. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 29. ? @ 0x00007fbc6213eac3 30. ? @ 0x00007fbc621d0850 2025.07.28 12:01:37.821784 [ 17243 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function neighbor doesn't match: passed 1, should be from 2 to 3: In scope SELECT neighbor(1). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, unsigned long&) @ 0x000000000a1f636b 4. /build/src/Functions/neighbor.cpp:83: DB::(anonymous namespace)::FunctionNeighbor::getReturnTypeImpl(std::vector, std::allocator>> const&) const @ 0x000000000db1eb0c 5. /build/src/Functions/IFunction.h:520: DB::IFunction::getReturnTypeImpl(std::vector> const&) const @ 0x000000000a06a2de 6. /build/src/Functions/IFunction.cpp:645: DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x0000000012d96b0c 7. /build/src/Functions/IFunction.cpp:585: DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x0000000012d9665b 8. /build/src/Functions/IFunction.cpp:606: DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x0000000012d96edc 9. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3544: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000014033cc9 10. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3838: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000014019a9e 11. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3980: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000014018e31 12. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:4304: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000014042fa7 13. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5605: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000014013749 14. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000140127f9 15. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000014011fce 16. /build/src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000001406ce8a 17. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000014973b42 18. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000001497268d 19. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000014974d24 20. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001492924b 21. /build/src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88641 22. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 23. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 24. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 25. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 26. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 27. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 28. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 29. ? @ 0x00007fbc6213eac3 30. ? @ 0x00007fbc621d0850 2025.07.28 12:01:37.881268 [ 17371 ] {3b19e5d6-15d0-4228-9685-f60113c1d8c6} executeQuery: Code: 70. DB::Exception: Cannot convert out of range floating point value to integer type. (CANNOT_CONVERT_TYPE) (version 25.3.6.10636.altinitytest (altinity build)) (from [::1]:44456) (comment: 01386_negative_float_constant_key_condition.sql) (query 6, line 17) (in query: SELECT t0.c1 FROM t0 WHERE NOT (t0.c1 OR (t0.c0 AND -1.0));), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000000a074fcb 4. /build/src/Common/FieldVisitorConvertToNumber.h:75: auto DB::Field::dispatch, DB::Field const&>(DB::FieldVisitorConvertToNumber&&, DB::Field const&) @ 0x0000000012dc2d10 5. /build/src/Common/FieldVisitors.h:24: DB::FunctionsLogicalDetail::FunctionAnyArityLogical::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000012dc42e1 6. /build/src/Functions/IFunction.h:437: DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000a069f2a 7. /build/src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000012d9965a 8. /build/src/Functions/IFunction.cpp:351: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d93b02 9. /build/src/Functions/IFunction.cpp:420: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d95059 10. /build/src/Functions/IFunction.cpp:498: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d95c72 11. /build/src/Interpreters/ActionsDAG.cpp:812: DB::ActionsDAG::evaluatePartialResult(std::unordered_map, std::equal_to, std::allocator>>&, std::vector> const&, unsigned long, bool) @ 0x0000000013fa38cc 12. /build/src/Interpreters/ActionsDAG.cpp:892: DB::ActionsDAG::updateHeader(DB::Block const&) const @ 0x0000000013fa29a8 13. /build/src/Processors/Transforms/FilterTransform.cpp:47: DB::FilterTransform::transformHeader(DB::Block const&, DB::ActionsDAG const*, String const&, bool) @ 0x0000000016c0e34d 14. /build/src/Processors/QueryPlan/FilterStep.cpp:135: DB::FilterStep::FilterStep(DB::Block const&, DB::ActionsDAG, String, bool) @ 0x0000000016dccc0b 15. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107](DB::Block const&, DB::ActionsDAG&&, String&, bool&) @ 0x0000000014960d7b 16. /build/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>>&) @ 0x000000001498172a 17. /build/src/Planner/Planner.cpp:1614: DB::Planner::buildPlanForQueryNode() @ 0x000000001497ae95 18. /build/src/Planner/Planner.cpp:1308: DB::Planner::buildQueryPlanIfNeeded() @ 0x000000001497685c 19. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:255: DB::InterpreterSelectQueryAnalyzer::getQueryPlan() @ 0x000000001497476d 20. /build/src/Interpreters/executeQuery.cpp:1405: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88806 21. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 22. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 23. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 24. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 25. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 26. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 27. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 28. ? @ 0x00007fbc6213eac3 29. ? @ 0x00007fbc621d0850 2025.07.28 12:01:37.892794 [ 17371 ] {} TCPHandler: Code: 70. DB::Exception: Cannot convert out of range floating point value to integer type. (CANNOT_CONVERT_TYPE), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000000a074fcb 4. /build/src/Common/FieldVisitorConvertToNumber.h:75: auto DB::Field::dispatch, DB::Field const&>(DB::FieldVisitorConvertToNumber&&, DB::Field const&) @ 0x0000000012dc2d10 5. /build/src/Common/FieldVisitors.h:24: DB::FunctionsLogicalDetail::FunctionAnyArityLogical::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000012dc42e1 6. /build/src/Functions/IFunction.h:437: DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000a069f2a 7. /build/src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000012d9965a 8. /build/src/Functions/IFunction.cpp:351: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d93b02 9. /build/src/Functions/IFunction.cpp:420: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d95059 10. /build/src/Functions/IFunction.cpp:498: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d95c72 11. /build/src/Interpreters/ActionsDAG.cpp:812: DB::ActionsDAG::evaluatePartialResult(std::unordered_map, std::equal_to, std::allocator>>&, std::vector> const&, unsigned long, bool) @ 0x0000000013fa38cc 12. /build/src/Interpreters/ActionsDAG.cpp:892: DB::ActionsDAG::updateHeader(DB::Block const&) const @ 0x0000000013fa29a8 13. /build/src/Processors/Transforms/FilterTransform.cpp:47: DB::FilterTransform::transformHeader(DB::Block const&, DB::ActionsDAG const*, String const&, bool) @ 0x0000000016c0e34d 14. /build/src/Processors/QueryPlan/FilterStep.cpp:135: DB::FilterStep::FilterStep(DB::Block const&, DB::ActionsDAG, String, bool) @ 0x0000000016dccc0b 15. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107](DB::Block const&, DB::ActionsDAG&&, String&, bool&) @ 0x0000000014960d7b 16. /build/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>>&) @ 0x000000001498172a 17. /build/src/Planner/Planner.cpp:1614: DB::Planner::buildPlanForQueryNode() @ 0x000000001497ae95 18. /build/src/Planner/Planner.cpp:1308: DB::Planner::buildQueryPlanIfNeeded() @ 0x000000001497685c 19. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:255: DB::InterpreterSelectQueryAnalyzer::getQueryPlan() @ 0x000000001497476d 20. /build/src/Interpreters/executeQuery.cpp:1405: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88806 21. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 22. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 23. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 24. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 25. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 26. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 27. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 28. ? @ 0x00007fbc6213eac3 29. ? @ 0x00007fbc621d0850 2025.07.28 12:01:37.894233 [ 17243 ] {5d38fd53-af4c-40f8-80c8-b8ce8fbf56e5} executeQuery: Code: 42. DB::Exception: Number of arguments for function neighbor doesn't match: passed 4, should be from 2 to 3: In scope SELECT neighbor(1, 2, 3, 4). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.6.10636.altinitytest (altinity build)) (from [::1]:44504) (comment: 00957_neighbor.sql) (query 4, line 6) (in query: -- greater than 3 arguments select neighbor(1,2,3,4);), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, unsigned long&) @ 0x000000000a1f636b 4. /build/src/Functions/neighbor.cpp:83: DB::(anonymous namespace)::FunctionNeighbor::getReturnTypeImpl(std::vector, std::allocator>> const&) const @ 0x000000000db1eb0c 5. /build/src/Functions/IFunction.h:520: DB::IFunction::getReturnTypeImpl(std::vector> const&) const @ 0x000000000a06a2de 6. /build/src/Functions/IFunction.cpp:645: DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x0000000012d96b0c 7. /build/src/Functions/IFunction.cpp:585: DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x0000000012d9665b 8. /build/src/Functions/IFunction.cpp:606: DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x0000000012d96edc 9. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3544: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000014033cc9 10. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3838: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000014019a9e 11. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3980: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000014018e31 12. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:4304: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000014042fa7 13. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5605: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000014013749 14. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000140127f9 15. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000014011fce 16. /build/src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000001406ce8a 17. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000014973b42 18. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000001497268d 19. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000014974d24 20. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001492924b 21. /build/src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88641 22. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 23. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 24. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 25. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 26. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 27. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 28. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 29. ? @ 0x00007fbc6213eac3 30. ? @ 0x00007fbc621d0850 2025.07.28 12:01:37.897665 [ 17243 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function neighbor doesn't match: passed 4, should be from 2 to 3: In scope SELECT neighbor(1, 2, 3, 4). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, unsigned long&) @ 0x000000000a1f636b 4. /build/src/Functions/neighbor.cpp:83: DB::(anonymous namespace)::FunctionNeighbor::getReturnTypeImpl(std::vector, std::allocator>> const&) const @ 0x000000000db1eb0c 5. /build/src/Functions/IFunction.h:520: DB::IFunction::getReturnTypeImpl(std::vector> const&) const @ 0x000000000a06a2de 6. /build/src/Functions/IFunction.cpp:645: DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x0000000012d96b0c 7. /build/src/Functions/IFunction.cpp:585: DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x0000000012d9665b 8. /build/src/Functions/IFunction.cpp:606: DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x0000000012d96edc 9. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3544: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000014033cc9 10. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3838: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000014019a9e 11. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3980: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000014018e31 12. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:4304: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000014042fa7 13. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5605: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000014013749 14. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000140127f9 15. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000014011fce 16. /build/src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000001406ce8a 17. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000014973b42 18. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000001497268d 19. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000014974d24 20. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001492924b 21. /build/src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88641 22. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 23. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 24. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 25. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 26. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 27. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 28. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 29. ? @ 0x00007fbc6213eac3 30. ? @ 0x00007fbc621d0850 2025.07.28 12:01:38.026351 [ 17243 ] {925d05ae-9d31-4c16-ab96-b83d7c83e9b2} 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 neighbor(dummy, 1, 'hello'). (NO_COMMON_TYPE) (version 25.3.6.10636.altinitytest (altinity build)) (from [::1]:44504) (comment: 00957_neighbor.sql) (query 5, line 8) (in query: -- bad default value select neighbor(dummy, 1, 'hello');), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception>&>(int, FormatStringHelperImpl::type, std::type_identity>&>::type>, String&&, std::basic_string_view>&) @ 0x000000000de9098b 4. /build/src/DataTypes/getLeastSupertype.cpp:69: std::shared_ptr DB::(anonymous namespace)::throwOrReturn<(DB::LeastSupertypeOnError)0, std::vector, std::allocator>>>(std::vector, std::allocator>> const&, std::basic_string_view>, int) @ 0x0000000013c6a73e 5. /build/src/DataTypes/getLeastSupertype.cpp:547: std::shared_ptr DB::getLeastSupertype<(DB::LeastSupertypeOnError)0>(std::vector, std::allocator>> const&) @ 0x0000000013c6dd15 6. /build/src/Functions/neighbor.cpp:100: DB::(anonymous namespace)::FunctionNeighbor::getReturnTypeImpl(std::vector, std::allocator>> const&) const @ 0x000000000db1e94b 7. /build/src/Functions/IFunction.h:520: DB::IFunction::getReturnTypeImpl(std::vector> const&) const @ 0x000000000a06a2de 8. /build/src/Functions/IFunction.cpp:645: DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x0000000012d96b0c 9. /build/src/Functions/IFunction.cpp:585: DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x0000000012d9665b 10. /build/src/Functions/IFunction.cpp:606: DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x0000000012d96edc 11. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3544: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000014033cc9 12. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3838: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000014019a9e 13. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3980: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000014018e31 14. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:4304: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000014042fa7 15. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5605: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000014013749 16. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000140127f9 17. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000014011fce 18. /build/src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000001406ce8a 19. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000014973b42 20. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000001497268d 21. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000014974d24 22. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001492924b 23. /build/src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88641 24. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 25. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 26. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 27. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 28. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 29. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 30. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 31. ? @ 0x00007fbc6213eac3 2025.07.28 12:01:38.043836 [ 17243 ] {} 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 neighbor(dummy, 1, 'hello'). (NO_COMMON_TYPE), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception>&>(int, FormatStringHelperImpl::type, std::type_identity>&>::type>, String&&, std::basic_string_view>&) @ 0x000000000de9098b 4. /build/src/DataTypes/getLeastSupertype.cpp:69: std::shared_ptr DB::(anonymous namespace)::throwOrReturn<(DB::LeastSupertypeOnError)0, std::vector, std::allocator>>>(std::vector, std::allocator>> const&, std::basic_string_view>, int) @ 0x0000000013c6a73e 5. /build/src/DataTypes/getLeastSupertype.cpp:547: std::shared_ptr DB::getLeastSupertype<(DB::LeastSupertypeOnError)0>(std::vector, std::allocator>> const&) @ 0x0000000013c6dd15 6. /build/src/Functions/neighbor.cpp:100: DB::(anonymous namespace)::FunctionNeighbor::getReturnTypeImpl(std::vector, std::allocator>> const&) const @ 0x000000000db1e94b 7. /build/src/Functions/IFunction.h:520: DB::IFunction::getReturnTypeImpl(std::vector> const&) const @ 0x000000000a06a2de 8. /build/src/Functions/IFunction.cpp:645: DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x0000000012d96b0c 9. /build/src/Functions/IFunction.cpp:585: DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x0000000012d9665b 10. /build/src/Functions/IFunction.cpp:606: DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x0000000012d96edc 11. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3544: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000014033cc9 12. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3838: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000014019a9e 13. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3980: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000014018e31 14. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:4304: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000014042fa7 15. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5605: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000014013749 16. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000140127f9 17. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000014011fce 18. /build/src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000001406ce8a 19. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000014973b42 20. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000001497268d 21. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000014974d24 22. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001492924b 23. /build/src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88641 24. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 25. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 26. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 27. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 28. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 29. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 30. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 31. ? @ 0x00007fbc6213eac3 2025.07.28 12:01:38.068235 [ 3961 ] {} test_13.rmt2 (7f9b740d-015c-470e-8cc6-8ba33be0dc63): auto DB::StorageReplicatedMergeTree::processQueueEntry(ReplicatedMergeTreeQueue::SelectedEntryPtr)::(anonymous class)::operator()(LogEntryPtr &) const: Code: 86. DB::HTTPException: Received error from remote server http://146b4357c08d:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Ftest%2F01165%2Ftest_13%2Frmt%2Freplicas%2F1&part=20250728_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.6.10636.altinitytest (altinity build)) '. (RECEIVED_ERROR_FROM_REMOTE_IO_SERVER), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.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 const&, int&&, String const&, unsigned long&&, String const&) @ 0x000000000feda8d9 4. /build/src/IO/HTTPCommon.cpp:104: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x000000000feda6e2 5. /build/src/IO/HTTPCommon.cpp:93: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x000000000feda537 6. /build/src/IO/ReadWriteBufferFromHTTP.cpp:277: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x000000001184a4c4 7. /build/src/IO/ReadWriteBufferFromHTTP.cpp:285: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x000000001184a615 8. /build/src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x000000001184ae59 9. /build/src/IO/ReadWriteBufferFromHTTP.cpp:472: void std::__function::__policy_invoker::__call_impl[abi:se190107]>(std::__function::__policy_storage const*) @ 0x000000001184cedd 10. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001184858b 11. /build/src/IO/ReadWriteBufferFromHTTP.cpp:465: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x000000001184bf0b 12. /build/src/IO/ReadBuffer.h:60: DB::ReadBuffer::next() @ 0x000000000a148c7b 13. /build/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) @ 0x0000000011849fb2 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]>&)>&, 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&) @ 0x0000000011841980 15. /build/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) @ 0x000000001621208e 16. /build/src/Storages/StorageReplicatedMergeTree.cpp:5228: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl[abi:se190107] const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000015f9a5fe 17. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000015ed8bfd 18. /build/src/Storages/StorageReplicatedMergeTree.cpp:2514: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x0000000015ec9aab 19. /build/src/Storages/StorageReplicatedMergeTree.cpp:2349: DB::StorageReplicatedMergeTree::executeLogEntry(DB::ReplicatedMergeTreeLogEntry&) @ 0x0000000015eba91b 20. /build/src/Storages/StorageReplicatedMergeTree.cpp:3876: bool std::__function::__policy_invoker&)>::__call_impl[abi:se190107])::$_1, bool (std::shared_ptr&)>>(std::__function::__policy_storage const*, std::shared_ptr&) @ 0x0000000015f9837e 21. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000165d6fc3 22. /build/src/Storages/StorageReplicatedMergeTree.cpp:3872: DB::StorageReplicatedMergeTree::processQueueEntry(std::shared_ptr) @ 0x0000000015efc18a 23. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001624c1b2 24. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000162f9c70 25. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x00000000162fa55a 26. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc6653 27. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000000fccc4c3 28. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc3d92 29. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fcca080 30. ? @ 0x00007fbc6213eac3 31. ? @ 0x00007fbc621d0850 (version 25.3.6.10636.altinitytest (altinity build)) 2025.07.28 12:01:38.235521 [ 17243 ] {47eeab91-d331-44d7-8027-cd7c9f2f9627} executeQuery: Code: 386. DB::Exception: There is no supertype for types Int8, 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 number, neighbor(number, 1, -10) FROM numbers(3). (NO_COMMON_TYPE) (version 25.3.6.10636.altinitytest (altinity build)) (from [::1]:44504) (comment: 00957_neighbor.sql) (query 6, line 10) (in query: -- types without common supertype (UInt64 and Int8) select number, neighbor(number, 1, -10) from numbers(3);), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception>&>(int, FormatStringHelperImpl::type, std::type_identity>&>::type>, String&&, std::basic_string_view>&) @ 0x000000000de9098b 4. /build/src/DataTypes/getLeastSupertype.cpp:69: 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) @ 0x0000000013c6b3be 5. /build/src/DataTypes/getLeastSupertype.cpp:140: std::shared_ptr DB::(anonymous namespace)::getNumericType<(DB::LeastSupertypeOnError)0>(std::unordered_set, std::equal_to, std::allocator> const&) @ 0x0000000013c6af52 6. /build/src/DataTypes/getLeastSupertype.cpp:688: std::shared_ptr DB::getLeastSupertype<(DB::LeastSupertypeOnError)0>(std::vector, std::allocator>> const&) @ 0x0000000013c6d9cb 7. /build/src/Functions/neighbor.cpp:100: DB::(anonymous namespace)::FunctionNeighbor::getReturnTypeImpl(std::vector, std::allocator>> const&) const @ 0x000000000db1e94b 8. /build/src/Functions/IFunction.h:520: DB::IFunction::getReturnTypeImpl(std::vector> const&) const @ 0x000000000a06a2de 9. /build/src/Functions/IFunction.cpp:645: DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x0000000012d96b0c 10. /build/src/Functions/IFunction.cpp:585: DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x0000000012d9665b 11. /build/src/Functions/IFunction.cpp:606: DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x0000000012d96edc 12. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3544: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000014033cc9 13. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3838: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000014019a9e 14. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3980: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000014018e31 15. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:4304: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000014042fa7 16. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5605: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000014013749 17. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000140127f9 18. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000014011fce 19. /build/src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000001406ce8a 20. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000014973b42 21. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000001497268d 22. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000014974d24 23. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001492924b 24. /build/src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88641 25. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 26. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 27. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 28. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 29. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 30. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 31. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 2025.07.28 12:01:38.239137 [ 17243 ] {} TCPHandler: Code: 386. DB::Exception: There is no supertype for types Int8, 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 number, neighbor(number, 1, -10) FROM numbers(3). (NO_COMMON_TYPE), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception>&>(int, FormatStringHelperImpl::type, std::type_identity>&>::type>, String&&, std::basic_string_view>&) @ 0x000000000de9098b 4. /build/src/DataTypes/getLeastSupertype.cpp:69: 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) @ 0x0000000013c6b3be 5. /build/src/DataTypes/getLeastSupertype.cpp:140: std::shared_ptr DB::(anonymous namespace)::getNumericType<(DB::LeastSupertypeOnError)0>(std::unordered_set, std::equal_to, std::allocator> const&) @ 0x0000000013c6af52 6. /build/src/DataTypes/getLeastSupertype.cpp:688: std::shared_ptr DB::getLeastSupertype<(DB::LeastSupertypeOnError)0>(std::vector, std::allocator>> const&) @ 0x0000000013c6d9cb 7. /build/src/Functions/neighbor.cpp:100: DB::(anonymous namespace)::FunctionNeighbor::getReturnTypeImpl(std::vector, std::allocator>> const&) const @ 0x000000000db1e94b 8. /build/src/Functions/IFunction.h:520: DB::IFunction::getReturnTypeImpl(std::vector> const&) const @ 0x000000000a06a2de 9. /build/src/Functions/IFunction.cpp:645: DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x0000000012d96b0c 10. /build/src/Functions/IFunction.cpp:585: DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x0000000012d9665b 11. /build/src/Functions/IFunction.cpp:606: DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x0000000012d96edc 12. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3544: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000014033cc9 13. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3838: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000014019a9e 14. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3980: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000014018e31 15. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:4304: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000014042fa7 16. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5605: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000014013749 17. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000140127f9 18. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000014011fce 19. /build/src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000001406ce8a 20. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000014973b42 21. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000001497268d 22. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000014974d24 23. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001492924b 24. /build/src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88641 25. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 26. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 27. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 28. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 29. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 30. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 31. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 2025.07.28 12:01:38.435487 [ 17243 ] {f474063f-6509-4c6e-b3a4-5388e60abf12} executeQuery: Code: 43. DB::Exception: Illegal type Nullable(UInt64) of second argument of function neighbor - should be an integer: In scope SELECT number, if(number > 1, number, NULL) AS offset, neighbor(number, offset) FROM numbers(3). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.6.10636.altinitytest (altinity build)) (from [::1]:44504) (comment: 00957_neighbor.sql) (query 7, line 12) (in query: -- nullable offset is not allowed select number, if(number > 1, number, null) as offset, neighbor(number, offset) from numbers(3);), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000a06a8eb 4. /build/src/Functions/neighbor.cpp:89: DB::(anonymous namespace)::FunctionNeighbor::getReturnTypeImpl(std::vector, std::allocator>> const&) const @ 0x000000000db1ebc4 5. /build/src/Functions/IFunction.h:520: DB::IFunction::getReturnTypeImpl(std::vector> const&) const @ 0x000000000a06a2de 6. /build/src/Functions/IFunction.cpp:645: DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x0000000012d96b0c 7. /build/src/Functions/IFunction.cpp:585: DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x0000000012d9665b 8. /build/src/Functions/IFunction.cpp:606: DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x0000000012d96edc 9. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3544: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000014033cc9 10. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3838: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000014019a9e 11. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3980: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000014018e31 12. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:4304: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000014042fa7 13. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5605: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000014013749 14. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000140127f9 15. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000014011fce 16. /build/src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000001406ce8a 17. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000014973b42 18. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000001497268d 19. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000014974d24 20. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001492924b 21. /build/src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88641 22. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 23. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 24. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 25. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 26. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 27. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 28. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 29. ? @ 0x00007fbc6213eac3 30. ? @ 0x00007fbc621d0850 2025.07.28 12:01:38.450071 [ 17243 ] {} TCPHandler: Code: 43. DB::Exception: Illegal type Nullable(UInt64) of second argument of function neighbor - should be an integer: In scope SELECT number, if(number > 1, number, NULL) AS offset, neighbor(number, offset) FROM numbers(3). (ILLEGAL_TYPE_OF_ARGUMENT), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000a06a8eb 4. /build/src/Functions/neighbor.cpp:89: DB::(anonymous namespace)::FunctionNeighbor::getReturnTypeImpl(std::vector, std::allocator>> const&) const @ 0x000000000db1ebc4 5. /build/src/Functions/IFunction.h:520: DB::IFunction::getReturnTypeImpl(std::vector> const&) const @ 0x000000000a06a2de 6. /build/src/Functions/IFunction.cpp:645: DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x0000000012d96b0c 7. /build/src/Functions/IFunction.cpp:585: DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x0000000012d9665b 8. /build/src/Functions/IFunction.cpp:606: DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x0000000012d96edc 9. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3544: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000014033cc9 10. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3838: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000014019a9e 11. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3980: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000014018e31 12. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:4304: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000014042fa7 13. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5605: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000014013749 14. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000140127f9 15. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000014011fce 16. /build/src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000001406ce8a 17. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000014973b42 18. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000001497268d 19. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000014974d24 20. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001492924b 21. /build/src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88641 22. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 23. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 24. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 25. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 26. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 27. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 28. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 29. ? @ 0x00007fbc6213eac3 30. ? @ 0x00007fbc621d0850 2025.07.28 12:01:38.746981 [ 3971 ] {} test_13.rmt2 (7f9b740d-015c-470e-8cc6-8ba33be0dc63): auto DB::StorageReplicatedMergeTree::processQueueEntry(ReplicatedMergeTreeQueue::SelectedEntryPtr)::(anonymous class)::operator()(LogEntryPtr &) const: Code: 86. DB::HTTPException: Received error from remote server http://146b4357c08d:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Ftest%2F01165%2Ftest_13%2Frmt%2Freplicas%2F1&part=20250728_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.6.10636.altinitytest (altinity build)) '. (RECEIVED_ERROR_FROM_REMOTE_IO_SERVER), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.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 const&, int&&, String const&, unsigned long&&, String const&) @ 0x000000000feda8d9 4. /build/src/IO/HTTPCommon.cpp:104: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x000000000feda6e2 5. /build/src/IO/HTTPCommon.cpp:93: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x000000000feda537 6. /build/src/IO/ReadWriteBufferFromHTTP.cpp:277: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x000000001184a4c4 7. /build/src/IO/ReadWriteBufferFromHTTP.cpp:285: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x000000001184a615 8. /build/src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x000000001184ae59 9. /build/src/IO/ReadWriteBufferFromHTTP.cpp:472: void std::__function::__policy_invoker::__call_impl[abi:se190107]>(std::__function::__policy_storage const*) @ 0x000000001184cedd 10. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001184858b 11. /build/src/IO/ReadWriteBufferFromHTTP.cpp:465: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x000000001184bf0b 12. /build/src/IO/ReadBuffer.h:60: DB::ReadBuffer::next() @ 0x000000000a148c7b 13. /build/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) @ 0x0000000011849fb2 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]>&)>&, 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&) @ 0x0000000011841980 15. /build/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) @ 0x000000001621208e 16. /build/src/Storages/StorageReplicatedMergeTree.cpp:5228: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl[abi:se190107] const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000015f9a5fe 17. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000015ed8bfd 18. /build/src/Storages/StorageReplicatedMergeTree.cpp:2514: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x0000000015ec9aab 19. /build/src/Storages/StorageReplicatedMergeTree.cpp:2349: DB::StorageReplicatedMergeTree::executeLogEntry(DB::ReplicatedMergeTreeLogEntry&) @ 0x0000000015eba91b 20. /build/src/Storages/StorageReplicatedMergeTree.cpp:3876: bool std::__function::__policy_invoker&)>::__call_impl[abi:se190107])::$_1, bool (std::shared_ptr&)>>(std::__function::__policy_storage const*, std::shared_ptr&) @ 0x0000000015f9837e 21. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000165d6fc3 22. /build/src/Storages/StorageReplicatedMergeTree.cpp:3872: DB::StorageReplicatedMergeTree::processQueueEntry(std::shared_ptr) @ 0x0000000015efc18a 23. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001624c1b2 24. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000162f9c70 25. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x00000000162fa55a 26. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc6653 27. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000000fccc4c3 28. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc3d92 29. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fcca080 30. ? @ 0x00007fbc6213eac3 31. ? @ 0x00007fbc621d0850 (version 25.3.6.10636.altinitytest (altinity build)) 2025.07.28 12:01:39.587061 [ 3960 ] {} test_13.rmt2 (7f9b740d-015c-470e-8cc6-8ba33be0dc63): auto DB::StorageReplicatedMergeTree::processQueueEntry(ReplicatedMergeTreeQueue::SelectedEntryPtr)::(anonymous class)::operator()(LogEntryPtr &) const: Code: 86. DB::HTTPException: Received error from remote server http://146b4357c08d:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Ftest%2F01165%2Ftest_13%2Frmt%2Freplicas%2F1&part=20250728_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.6.10636.altinitytest (altinity build)) '. (RECEIVED_ERROR_FROM_REMOTE_IO_SERVER), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.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 const&, int&&, String const&, unsigned long&&, String const&) @ 0x000000000feda8d9 4. /build/src/IO/HTTPCommon.cpp:104: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x000000000feda6e2 5. /build/src/IO/HTTPCommon.cpp:93: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x000000000feda537 6. /build/src/IO/ReadWriteBufferFromHTTP.cpp:277: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x000000001184a4c4 7. /build/src/IO/ReadWriteBufferFromHTTP.cpp:285: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x000000001184a615 8. /build/src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x000000001184ae59 9. /build/src/IO/ReadWriteBufferFromHTTP.cpp:472: void std::__function::__policy_invoker::__call_impl[abi:se190107]>(std::__function::__policy_storage const*) @ 0x000000001184cedd 10. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001184858b 11. /build/src/IO/ReadWriteBufferFromHTTP.cpp:465: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x000000001184bf0b 12. /build/src/IO/ReadBuffer.h:60: DB::ReadBuffer::next() @ 0x000000000a148c7b 13. /build/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) @ 0x0000000011849fb2 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]>&)>&, 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&) @ 0x0000000011841980 15. /build/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) @ 0x000000001621208e 16. /build/src/Storages/StorageReplicatedMergeTree.cpp:5228: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl[abi:se190107] const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000015f9a5fe 17. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000015ed8bfd 18. /build/src/Storages/StorageReplicatedMergeTree.cpp:2514: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x0000000015ec9aab 19. /build/src/Storages/StorageReplicatedMergeTree.cpp:2349: DB::StorageReplicatedMergeTree::executeLogEntry(DB::ReplicatedMergeTreeLogEntry&) @ 0x0000000015eba91b 20. /build/src/Storages/StorageReplicatedMergeTree.cpp:3876: bool std::__function::__policy_invoker&)>::__call_impl[abi:se190107])::$_1, bool (std::shared_ptr&)>>(std::__function::__policy_storage const*, std::shared_ptr&) @ 0x0000000015f9837e 21. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000165d6fc3 22. /build/src/Storages/StorageReplicatedMergeTree.cpp:3872: DB::StorageReplicatedMergeTree::processQueueEntry(std::shared_ptr) @ 0x0000000015efc18a 23. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001624c1b2 24. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000162f9c70 25. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x00000000162fa55a 26. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc6653 27. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000000fccc4c3 28. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc3d92 29. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fcca080 30. ? @ 0x00007fbc6213eac3 31. ? @ 0x00007fbc621d0850 (version 25.3.6.10636.altinitytest (altinity build)) 2025.07.28 12:01:40.460388 [ 3969 ] {} test_13.rmt2 (7f9b740d-015c-470e-8cc6-8ba33be0dc63): auto DB::StorageReplicatedMergeTree::processQueueEntry(ReplicatedMergeTreeQueue::SelectedEntryPtr)::(anonymous class)::operator()(LogEntryPtr &) const: Code: 86. DB::HTTPException: Received error from remote server http://146b4357c08d:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Ftest%2F01165%2Ftest_13%2Frmt%2Freplicas%2F1&part=20250728_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.6.10636.altinitytest (altinity build)) '. (RECEIVED_ERROR_FROM_REMOTE_IO_SERVER), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.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 const&, int&&, String const&, unsigned long&&, String const&) @ 0x000000000feda8d9 4. /build/src/IO/HTTPCommon.cpp:104: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x000000000feda6e2 5. /build/src/IO/HTTPCommon.cpp:93: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x000000000feda537 6. /build/src/IO/ReadWriteBufferFromHTTP.cpp:277: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x000000001184a4c4 7. /build/src/IO/ReadWriteBufferFromHTTP.cpp:285: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x000000001184a615 8. /build/src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x000000001184ae59 9. /build/src/IO/ReadWriteBufferFromHTTP.cpp:472: void std::__function::__policy_invoker::__call_impl[abi:se190107]>(std::__function::__policy_storage const*) @ 0x000000001184cedd 10. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001184858b 11. /build/src/IO/ReadWriteBufferFromHTTP.cpp:465: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x000000001184bf0b 12. /build/src/IO/ReadBuffer.h:60: DB::ReadBuffer::next() @ 0x000000000a148c7b 13. /build/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) @ 0x0000000011849fb2 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]>&)>&, 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&) @ 0x0000000011841980 15. /build/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) @ 0x000000001621208e 16. /build/src/Storages/StorageReplicatedMergeTree.cpp:5228: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl[abi:se190107] const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000015f9a5fe 17. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000015ed8bfd 18. /build/src/Storages/StorageReplicatedMergeTree.cpp:2514: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x0000000015ec9aab 19. /build/src/Storages/StorageReplicatedMergeTree.cpp:2349: DB::StorageReplicatedMergeTree::executeLogEntry(DB::ReplicatedMergeTreeLogEntry&) @ 0x0000000015eba91b 20. /build/src/Storages/StorageReplicatedMergeTree.cpp:3876: bool std::__function::__policy_invoker&)>::__call_impl[abi:se190107])::$_1, bool (std::shared_ptr&)>>(std::__function::__policy_storage const*, std::shared_ptr&) @ 0x0000000015f9837e 21. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000165d6fc3 22. /build/src/Storages/StorageReplicatedMergeTree.cpp:3872: DB::StorageReplicatedMergeTree::processQueueEntry(std::shared_ptr) @ 0x0000000015efc18a 23. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001624c1b2 24. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000162f9c70 25. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x00000000162fa55a 26. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc6653 27. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000000fccc4c3 28. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc3d92 29. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fcca080 30. ? @ 0x00007fbc6213eac3 31. ? @ 0x00007fbc621d0850 (version 25.3.6.10636.altinitytest (altinity build)) 2025.07.28 12:01:41.402052 [ 3972 ] {} test_13.rmt2 (7f9b740d-015c-470e-8cc6-8ba33be0dc63): auto DB::StorageReplicatedMergeTree::processQueueEntry(ReplicatedMergeTreeQueue::SelectedEntryPtr)::(anonymous class)::operator()(LogEntryPtr &) const: Code: 86. DB::HTTPException: Received error from remote server http://146b4357c08d:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Ftest%2F01165%2Ftest_13%2Frmt%2Freplicas%2F1&part=20250728_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.6.10636.altinitytest (altinity build)) '. (RECEIVED_ERROR_FROM_REMOTE_IO_SERVER), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.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 const&, int&&, String const&, unsigned long&&, String const&) @ 0x000000000feda8d9 4. /build/src/IO/HTTPCommon.cpp:104: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x000000000feda6e2 5. /build/src/IO/HTTPCommon.cpp:93: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x000000000feda537 6. /build/src/IO/ReadWriteBufferFromHTTP.cpp:277: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x000000001184a4c4 7. /build/src/IO/ReadWriteBufferFromHTTP.cpp:285: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x000000001184a615 8. /build/src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x000000001184ae59 9. /build/src/IO/ReadWriteBufferFromHTTP.cpp:472: void std::__function::__policy_invoker::__call_impl[abi:se190107]>(std::__function::__policy_storage const*) @ 0x000000001184cedd 10. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001184858b 11. /build/src/IO/ReadWriteBufferFromHTTP.cpp:465: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x000000001184bf0b 12. /build/src/IO/ReadBuffer.h:60: DB::ReadBuffer::next() @ 0x000000000a148c7b 13. /build/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) @ 0x0000000011849fb2 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]>&)>&, 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&) @ 0x0000000011841980 15. /build/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) @ 0x000000001621208e 16. /build/src/Storages/StorageReplicatedMergeTree.cpp:5228: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl[abi:se190107] const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000015f9a5fe 17. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000015ed8bfd 18. /build/src/Storages/StorageReplicatedMergeTree.cpp:2514: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x0000000015ec9aab 19. /build/src/Storages/StorageReplicatedMergeTree.cpp:2349: DB::StorageReplicatedMergeTree::executeLogEntry(DB::ReplicatedMergeTreeLogEntry&) @ 0x0000000015eba91b 20. /build/src/Storages/StorageReplicatedMergeTree.cpp:3876: bool std::__function::__policy_invoker&)>::__call_impl[abi:se190107])::$_1, bool (std::shared_ptr&)>>(std::__function::__policy_storage const*, std::shared_ptr&) @ 0x0000000015f9837e 21. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000165d6fc3 22. /build/src/Storages/StorageReplicatedMergeTree.cpp:3872: DB::StorageReplicatedMergeTree::processQueueEntry(std::shared_ptr) @ 0x0000000015efc18a 23. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001624c1b2 24. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000162f9c70 25. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x00000000162fa55a 26. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc6653 27. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000000fccc4c3 28. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc3d92 29. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fcca080 30. ? @ 0x00007fbc6213eac3 31. ? @ 0x00007fbc621d0850 (version 25.3.6.10636.altinitytest (altinity build)) 2025.07.28 12:01:41.782211 [ 3942 ] {} MergeTreeBackgroundExecutor: Exception while executing background task {a43d84e8-330f-48ce-9237-8d85ff00e0c0::202507_87_97_2}: 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. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, char const*&&, char const*&&) @ 0x000000000fc1a8eb 4. /build/src/Common/MemoryTracker.cpp:196: MemoryTracker::injectFault() const @ 0x000000000fc18390 5. /build/src/Storages/MergeTree/MergePlainMergeTreeTask.cpp:153: DB::MergePlainMergeTreeTask::finish() @ 0x000000001666f399 6. /build/src/Storages/MergeTree/MergePlainMergeTreeTask.cpp:72: DB::MergePlainMergeTreeTask::executeStep() @ 0x000000001666e852 7. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000162fc850 8. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x00000000162fd193 9. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc6653 10. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000000fccc4c3 11. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc3d92 12. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fcca080 13. ? @ 0x00007fbc6213eac3 14. ? @ 0x00007fbc621d0850 (version 25.3.6.10636.altinitytest (altinity build)) 2025.07.28 12:01:42.286776 [ 4446 ] {958de41e-4729-418f-a1cf-3076a7ebcd04} executeQuery: Code: 219. DB::Exception: New table appeared in database being dropped or detached. Try again. (DATABASE_NOT_EMPTY) (version 25.3.6.10636.altinitytest (altinity build)) (from [::1]:50842) (comment: 03206_is_null_constant_result_old_analyzer_bug.sql) (in query: DROP DATABASE IF EXISTS test_tazxmnlv SYNC ), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000000a074fcb 4. /build/src/Interpreters/DatabaseCatalog.cpp:608: DB::DatabaseCatalog::detachDatabase(std::shared_ptr, String const&, bool, bool) @ 0x00000000144f41b9 5. /build/src/Interpreters/InterpreterDropQuery.cpp:482: DB::InterpreterDropQuery::executeToDatabaseImpl(DB::ASTDropQuery const&, std::shared_ptr&, std::vector, DB::UUIDTag>, std::allocator, DB::UUIDTag>>>&) @ 0x00000000149179be 6. /build/src/Interpreters/InterpreterDropQuery.cpp:363: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x0000000014913988 7. /build/src/Interpreters/InterpreterDropQuery.cpp:99: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000014913142 8. /build/src/Interpreters/InterpreterDropQuery.cpp:72: DB::InterpreterDropQuery::execute() @ 0x0000000014912b65 9. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88dc9 10. /build/src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x0000000014c8ca7b 11. /build/src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000001686da12 12. /build/src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x0000000016870807 13. /build/src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x0000000016907e99 14. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 15. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 16. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 17. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 18. ? @ 0x00007fbc6213eac3 19. ? @ 0x00007fbc621d0850 2025.07.28 12:01:42.290707 [ 4446 ] {958de41e-4729-418f-a1cf-3076a7ebcd04} 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. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000000a074fcb 4. /build/src/Interpreters/DatabaseCatalog.cpp:608: DB::DatabaseCatalog::detachDatabase(std::shared_ptr, String const&, bool, bool) @ 0x00000000144f41b9 5. /build/src/Interpreters/InterpreterDropQuery.cpp:482: DB::InterpreterDropQuery::executeToDatabaseImpl(DB::ASTDropQuery const&, std::shared_ptr&, std::vector, DB::UUIDTag>, std::allocator, DB::UUIDTag>>>&) @ 0x00000000149179be 6. /build/src/Interpreters/InterpreterDropQuery.cpp:363: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x0000000014913988 7. /build/src/Interpreters/InterpreterDropQuery.cpp:99: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000014913142 8. /build/src/Interpreters/InterpreterDropQuery.cpp:72: DB::InterpreterDropQuery::execute() @ 0x0000000014912b65 9. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88dc9 10. /build/src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x0000000014c8ca7b 11. /build/src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000001686da12 12. /build/src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x0000000016870807 13. /build/src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x0000000016907e99 14. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 15. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 16. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 17. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 18. ? @ 0x00007fbc6213eac3 19. ? @ 0x00007fbc621d0850 (version 25.3.6.10636.altinitytest (altinity build)) 2025.07.28 12:01:42.363627 [ 3963 ] {} test_13.rmt2 (7f9b740d-015c-470e-8cc6-8ba33be0dc63): auto DB::StorageReplicatedMergeTree::processQueueEntry(ReplicatedMergeTreeQueue::SelectedEntryPtr)::(anonymous class)::operator()(LogEntryPtr &) const: Code: 86. DB::HTTPException: Received error from remote server http://146b4357c08d:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Ftest%2F01165%2Ftest_13%2Frmt%2Freplicas%2F1&part=20250728_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.6.10636.altinitytest (altinity build)) '. (RECEIVED_ERROR_FROM_REMOTE_IO_SERVER), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.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 const&, int&&, String const&, unsigned long&&, String const&) @ 0x000000000feda8d9 4. /build/src/IO/HTTPCommon.cpp:104: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x000000000feda6e2 5. /build/src/IO/HTTPCommon.cpp:93: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x000000000feda537 6. /build/src/IO/ReadWriteBufferFromHTTP.cpp:277: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x000000001184a4c4 7. /build/src/IO/ReadWriteBufferFromHTTP.cpp:285: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x000000001184a615 8. /build/src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x000000001184ae59 9. /build/src/IO/ReadWriteBufferFromHTTP.cpp:472: void std::__function::__policy_invoker::__call_impl[abi:se190107]>(std::__function::__policy_storage const*) @ 0x000000001184cedd 10. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001184858b 11. /build/src/IO/ReadWriteBufferFromHTTP.cpp:465: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x000000001184bf0b 12. /build/src/IO/ReadBuffer.h:60: DB::ReadBuffer::next() @ 0x000000000a148c7b 13. /build/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) @ 0x0000000011849fb2 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]>&)>&, 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&) @ 0x0000000011841980 15. /build/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) @ 0x000000001621208e 16. /build/src/Storages/StorageReplicatedMergeTree.cpp:5228: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl[abi:se190107] const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000015f9a5fe 17. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000015ed8bfd 18. /build/src/Storages/StorageReplicatedMergeTree.cpp:2514: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x0000000015ec9aab 19. /build/src/Storages/StorageReplicatedMergeTree.cpp:2349: DB::StorageReplicatedMergeTree::executeLogEntry(DB::ReplicatedMergeTreeLogEntry&) @ 0x0000000015eba91b 20. /build/src/Storages/StorageReplicatedMergeTree.cpp:3876: bool std::__function::__policy_invoker&)>::__call_impl[abi:se190107])::$_1, bool (std::shared_ptr&)>>(std::__function::__policy_storage const*, std::shared_ptr&) @ 0x0000000015f9837e 21. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000165d6fc3 22. /build/src/Storages/StorageReplicatedMergeTree.cpp:3872: DB::StorageReplicatedMergeTree::processQueueEntry(std::shared_ptr) @ 0x0000000015efc18a 23. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001624c1b2 24. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000162f9c70 25. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x00000000162fa55a 26. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc6653 27. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000000fccc4c3 28. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc3d92 29. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fcca080 30. ? @ 0x00007fbc6213eac3 31. ? @ 0x00007fbc621d0850 (version 25.3.6.10636.altinitytest (altinity build)) 2025.07.28 12:01:43.170327 [ 3968 ] {} test_13.rmt2 (7f9b740d-015c-470e-8cc6-8ba33be0dc63): auto DB::StorageReplicatedMergeTree::processQueueEntry(ReplicatedMergeTreeQueue::SelectedEntryPtr)::(anonymous class)::operator()(LogEntryPtr &) const: Code: 86. DB::HTTPException: Received error from remote server http://146b4357c08d:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Ftest%2F01165%2Ftest_13%2Frmt%2Freplicas%2F1&part=20250728_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.6.10636.altinitytest (altinity build)) '. (RECEIVED_ERROR_FROM_REMOTE_IO_SERVER), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.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 const&, int&&, String const&, unsigned long&&, String const&) @ 0x000000000feda8d9 4. /build/src/IO/HTTPCommon.cpp:104: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x000000000feda6e2 5. /build/src/IO/HTTPCommon.cpp:93: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x000000000feda537 6. /build/src/IO/ReadWriteBufferFromHTTP.cpp:277: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x000000001184a4c4 7. /build/src/IO/ReadWriteBufferFromHTTP.cpp:285: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x000000001184a615 8. /build/src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x000000001184ae59 9. /build/src/IO/ReadWriteBufferFromHTTP.cpp:472: void std::__function::__policy_invoker::__call_impl[abi:se190107]>(std::__function::__policy_storage const*) @ 0x000000001184cedd 10. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001184858b 11. /build/src/IO/ReadWriteBufferFromHTTP.cpp:465: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x000000001184bf0b 12. /build/src/IO/ReadBuffer.h:60: DB::ReadBuffer::next() @ 0x000000000a148c7b 13. /build/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) @ 0x0000000011849fb2 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]>&)>&, 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&) @ 0x0000000011841980 15. /build/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) @ 0x000000001621208e 16. /build/src/Storages/StorageReplicatedMergeTree.cpp:5228: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl[abi:se190107] const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000015f9a5fe 17. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000015ed8bfd 18. /build/src/Storages/StorageReplicatedMergeTree.cpp:2514: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x0000000015ec9aab 19. /build/src/Storages/StorageReplicatedMergeTree.cpp:2349: DB::StorageReplicatedMergeTree::executeLogEntry(DB::ReplicatedMergeTreeLogEntry&) @ 0x0000000015eba91b 20. /build/src/Storages/StorageReplicatedMergeTree.cpp:3876: bool std::__function::__policy_invoker&)>::__call_impl[abi:se190107])::$_1, bool (std::shared_ptr&)>>(std::__function::__policy_storage const*, std::shared_ptr&) @ 0x0000000015f9837e 21. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000165d6fc3 22. /build/src/Storages/StorageReplicatedMergeTree.cpp:3872: DB::StorageReplicatedMergeTree::processQueueEntry(std::shared_ptr) @ 0x0000000015efc18a 23. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001624c1b2 24. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000162f9c70 25. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x00000000162fa55a 26. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc6653 27. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000000fccc4c3 28. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc3d92 29. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fcca080 30. ? @ 0x00007fbc6213eac3 31. ? @ 0x00007fbc621d0850 (version 25.3.6.10636.altinitytest (altinity build)) 2025.07.28 12:01:43.582896 [ 3960 ] {} test_13.rmt2 (7f9b740d-015c-470e-8cc6-8ba33be0dc63): auto DB::StorageReplicatedMergeTree::processQueueEntry(ReplicatedMergeTreeQueue::SelectedEntryPtr)::(anonymous class)::operator()(LogEntryPtr &) const: Code: 86. DB::HTTPException: Received error from remote server http://146b4357c08d:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Ftest%2F01165%2Ftest_13%2Frmt%2Freplicas%2F1&part=20250728_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.6.10636.altinitytest (altinity build)) '. (RECEIVED_ERROR_FROM_REMOTE_IO_SERVER), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.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 const&, int&&, String const&, unsigned long&&, String const&) @ 0x000000000feda8d9 4. /build/src/IO/HTTPCommon.cpp:104: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x000000000feda6e2 5. /build/src/IO/HTTPCommon.cpp:93: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x000000000feda537 6. /build/src/IO/ReadWriteBufferFromHTTP.cpp:277: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x000000001184a4c4 7. /build/src/IO/ReadWriteBufferFromHTTP.cpp:285: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x000000001184a615 8. /build/src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x000000001184ae59 9. /build/src/IO/ReadWriteBufferFromHTTP.cpp:472: void std::__function::__policy_invoker::__call_impl[abi:se190107]>(std::__function::__policy_storage const*) @ 0x000000001184cedd 10. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001184858b 11. /build/src/IO/ReadWriteBufferFromHTTP.cpp:465: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x000000001184bf0b 12. /build/src/IO/ReadBuffer.h:60: DB::ReadBuffer::next() @ 0x000000000a148c7b 13. /build/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) @ 0x0000000011849fb2 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]>&)>&, 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&) @ 0x0000000011841980 15. /build/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) @ 0x000000001621208e 16. /build/src/Storages/StorageReplicatedMergeTree.cpp:5228: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl[abi:se190107] const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000015f9a5fe 17. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000015ed8bfd 18. /build/src/Storages/StorageReplicatedMergeTree.cpp:2514: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x0000000015ec9aab 19. /build/src/Storages/StorageReplicatedMergeTree.cpp:2349: DB::StorageReplicatedMergeTree::executeLogEntry(DB::ReplicatedMergeTreeLogEntry&) @ 0x0000000015eba91b 20. /build/src/Storages/StorageReplicatedMergeTree.cpp:3876: bool std::__function::__policy_invoker&)>::__call_impl[abi:se190107])::$_1, bool (std::shared_ptr&)>>(std::__function::__policy_storage const*, std::shared_ptr&) @ 0x0000000015f9837e 21. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000165d6fc3 22. /build/src/Storages/StorageReplicatedMergeTree.cpp:3872: DB::StorageReplicatedMergeTree::processQueueEntry(std::shared_ptr) @ 0x0000000015efc18a 23. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001624c1b2 24. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000162f9c70 25. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x00000000162fa55a 26. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc6653 27. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000000fccc4c3 28. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc3d92 29. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fcca080 30. ? @ 0x00007fbc6213eac3 31. ? @ 0x00007fbc621d0850 (version 25.3.6.10636.altinitytest (altinity build)) 2025.07.28 12:01:43.926332 [ 3965 ] {} test_13.rmt2 (7f9b740d-015c-470e-8cc6-8ba33be0dc63): auto DB::StorageReplicatedMergeTree::processQueueEntry(ReplicatedMergeTreeQueue::SelectedEntryPtr)::(anonymous class)::operator()(LogEntryPtr &) const: Code: 86. DB::HTTPException: Received error from remote server http://146b4357c08d:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Ftest%2F01165%2Ftest_13%2Frmt%2Freplicas%2F1&part=20250728_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.6.10636.altinitytest (altinity build)) '. (RECEIVED_ERROR_FROM_REMOTE_IO_SERVER), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.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 const&, int&&, String const&, unsigned long&&, String const&) @ 0x000000000feda8d9 4. /build/src/IO/HTTPCommon.cpp:104: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x000000000feda6e2 5. /build/src/IO/HTTPCommon.cpp:93: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x000000000feda537 6. /build/src/IO/ReadWriteBufferFromHTTP.cpp:277: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x000000001184a4c4 7. /build/src/IO/ReadWriteBufferFromHTTP.cpp:285: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x000000001184a615 8. /build/src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x000000001184ae59 9. /build/src/IO/ReadWriteBufferFromHTTP.cpp:472: void std::__function::__policy_invoker::__call_impl[abi:se190107]>(std::__function::__policy_storage const*) @ 0x000000001184cedd 10. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001184858b 11. /build/src/IO/ReadWriteBufferFromHTTP.cpp:465: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x000000001184bf0b 12. /build/src/IO/ReadBuffer.h:60: DB::ReadBuffer::next() @ 0x000000000a148c7b 13. /build/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) @ 0x0000000011849fb2 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]>&)>&, 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&) @ 0x0000000011841980 15. /build/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) @ 0x000000001621208e 16. /build/src/Storages/StorageReplicatedMergeTree.cpp:5228: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl[abi:se190107] const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000015f9a5fe 17. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000015ed8bfd 18. /build/src/Storages/StorageReplicatedMergeTree.cpp:2514: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x0000000015ec9aab 19. /build/src/Storages/StorageReplicatedMergeTree.cpp:2349: DB::StorageReplicatedMergeTree::executeLogEntry(DB::ReplicatedMergeTreeLogEntry&) @ 0x0000000015eba91b 20. /build/src/Storages/StorageReplicatedMergeTree.cpp:3876: bool std::__function::__policy_invoker&)>::__call_impl[abi:se190107])::$_1, bool (std::shared_ptr&)>>(std::__function::__policy_storage const*, std::shared_ptr&) @ 0x0000000015f9837e 21. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000165d6fc3 22. /build/src/Storages/StorageReplicatedMergeTree.cpp:3872: DB::StorageReplicatedMergeTree::processQueueEntry(std::shared_ptr) @ 0x0000000015efc18a 23. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001624c1b2 24. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000162f9c70 25. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x00000000162fa55a 26. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc6653 27. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000000fccc4c3 28. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc3d92 29. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fcca080 30. ? @ 0x00007fbc6213eac3 31. ? @ 0x00007fbc621d0850 (version 25.3.6.10636.altinitytest (altinity build)) 2025.07.28 12:01:44.841853 [ 3962 ] {} test_13.rmt2 (7f9b740d-015c-470e-8cc6-8ba33be0dc63): auto DB::StorageReplicatedMergeTree::processQueueEntry(ReplicatedMergeTreeQueue::SelectedEntryPtr)::(anonymous class)::operator()(LogEntryPtr &) const: Code: 86. DB::HTTPException: Received error from remote server http://146b4357c08d:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Ftest%2F01165%2Ftest_13%2Frmt%2Freplicas%2F1&part=20250728_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.6.10636.altinitytest (altinity build)) '. (RECEIVED_ERROR_FROM_REMOTE_IO_SERVER), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.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 const&, int&&, String const&, unsigned long&&, String const&) @ 0x000000000feda8d9 4. /build/src/IO/HTTPCommon.cpp:104: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x000000000feda6e2 5. /build/src/IO/HTTPCommon.cpp:93: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x000000000feda537 6. /build/src/IO/ReadWriteBufferFromHTTP.cpp:277: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x000000001184a4c4 7. /build/src/IO/ReadWriteBufferFromHTTP.cpp:285: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x000000001184a615 8. /build/src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x000000001184ae59 9. /build/src/IO/ReadWriteBufferFromHTTP.cpp:472: void std::__function::__policy_invoker::__call_impl[abi:se190107]>(std::__function::__policy_storage const*) @ 0x000000001184cedd 10. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001184858b 11. /build/src/IO/ReadWriteBufferFromHTTP.cpp:465: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x000000001184bf0b 12. /build/src/IO/ReadBuffer.h:60: DB::ReadBuffer::next() @ 0x000000000a148c7b 13. /build/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) @ 0x0000000011849fb2 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]>&)>&, 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&) @ 0x0000000011841980 15. /build/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) @ 0x000000001621208e 16. /build/src/Storages/StorageReplicatedMergeTree.cpp:5228: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl[abi:se190107] const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000015f9a5fe 17. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000015ed8bfd 18. /build/src/Storages/StorageReplicatedMergeTree.cpp:2514: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x0000000015ec9aab 19. /build/src/Storages/StorageReplicatedMergeTree.cpp:2349: DB::StorageReplicatedMergeTree::executeLogEntry(DB::ReplicatedMergeTreeLogEntry&) @ 0x0000000015eba91b 20. /build/src/Storages/StorageReplicatedMergeTree.cpp:3876: bool std::__function::__policy_invoker&)>::__call_impl[abi:se190107])::$_1, bool (std::shared_ptr&)>>(std::__function::__policy_storage const*, std::shared_ptr&) @ 0x0000000015f9837e 21. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000165d6fc3 22. /build/src/Storages/StorageReplicatedMergeTree.cpp:3872: DB::StorageReplicatedMergeTree::processQueueEntry(std::shared_ptr) @ 0x0000000015efc18a 23. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001624c1b2 24. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000162f9c70 25. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x00000000162fa55a 26. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc6653 27. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000000fccc4c3 28. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc3d92 29. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fcca080 30. ? @ 0x00007fbc6213eac3 31. ? @ 0x00007fbc621d0850 (version 25.3.6.10636.altinitytest (altinity build)) 2025.07.28 12:01:45.661919 [ 3966 ] {} test_13.rmt2 (7f9b740d-015c-470e-8cc6-8ba33be0dc63): auto DB::StorageReplicatedMergeTree::processQueueEntry(ReplicatedMergeTreeQueue::SelectedEntryPtr)::(anonymous class)::operator()(LogEntryPtr &) const: Code: 86. DB::HTTPException: Received error from remote server http://146b4357c08d:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Ftest%2F01165%2Ftest_13%2Frmt%2Freplicas%2F1&part=20250728_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.6.10636.altinitytest (altinity build)) '. (RECEIVED_ERROR_FROM_REMOTE_IO_SERVER), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.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 const&, int&&, String const&, unsigned long&&, String const&) @ 0x000000000feda8d9 4. /build/src/IO/HTTPCommon.cpp:104: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x000000000feda6e2 5. /build/src/IO/HTTPCommon.cpp:93: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x000000000feda537 6. /build/src/IO/ReadWriteBufferFromHTTP.cpp:277: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x000000001184a4c4 7. /build/src/IO/ReadWriteBufferFromHTTP.cpp:285: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x000000001184a615 8. /build/src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x000000001184ae59 9. /build/src/IO/ReadWriteBufferFromHTTP.cpp:472: void std::__function::__policy_invoker::__call_impl[abi:se190107]>(std::__function::__policy_storage const*) @ 0x000000001184cedd 10. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001184858b 11. /build/src/IO/ReadWriteBufferFromHTTP.cpp:465: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x000000001184bf0b 12. /build/src/IO/ReadBuffer.h:60: DB::ReadBuffer::next() @ 0x000000000a148c7b 13. /build/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) @ 0x0000000011849fb2 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]>&)>&, 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&) @ 0x0000000011841980 15. /build/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) @ 0x000000001621208e 16. /build/src/Storages/StorageReplicatedMergeTree.cpp:5228: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl[abi:se190107] const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000015f9a5fe 17. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000015ed8bfd 18. /build/src/Storages/StorageReplicatedMergeTree.cpp:2514: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x0000000015ec9aab 19. /build/src/Storages/StorageReplicatedMergeTree.cpp:2349: DB::StorageReplicatedMergeTree::executeLogEntry(DB::ReplicatedMergeTreeLogEntry&) @ 0x0000000015eba91b 20. /build/src/Storages/StorageReplicatedMergeTree.cpp:3876: bool std::__function::__policy_invoker&)>::__call_impl[abi:se190107])::$_1, bool (std::shared_ptr&)>>(std::__function::__policy_storage const*, std::shared_ptr&) @ 0x0000000015f9837e 21. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000165d6fc3 22. /build/src/Storages/StorageReplicatedMergeTree.cpp:3872: DB::StorageReplicatedMergeTree::processQueueEntry(std::shared_ptr) @ 0x0000000015efc18a 23. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001624c1b2 24. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000162f9c70 25. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x00000000162fa55a 26. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc6653 27. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000000fccc4c3 28. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc3d92 29. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fcca080 30. ? @ 0x00007fbc6213eac3 31. ? @ 0x00007fbc621d0850 (version 25.3.6.10636.altinitytest (altinity build)) 2025.07.28 12:01:46.174615 [ 3974 ] {} test_13.rmt2 (7f9b740d-015c-470e-8cc6-8ba33be0dc63): auto DB::StorageReplicatedMergeTree::processQueueEntry(ReplicatedMergeTreeQueue::SelectedEntryPtr)::(anonymous class)::operator()(LogEntryPtr &) const: Code: 86. DB::HTTPException: Received error from remote server http://146b4357c08d:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Ftest%2F01165%2Ftest_13%2Frmt%2Freplicas%2F1&part=20250728_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.6.10636.altinitytest (altinity build)) '. (RECEIVED_ERROR_FROM_REMOTE_IO_SERVER), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.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 const&, int&&, String const&, unsigned long&&, String const&) @ 0x000000000feda8d9 4. /build/src/IO/HTTPCommon.cpp:104: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x000000000feda6e2 5. /build/src/IO/HTTPCommon.cpp:93: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x000000000feda537 6. /build/src/IO/ReadWriteBufferFromHTTP.cpp:277: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x000000001184a4c4 7. /build/src/IO/ReadWriteBufferFromHTTP.cpp:285: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x000000001184a615 8. /build/src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x000000001184ae59 9. /build/src/IO/ReadWriteBufferFromHTTP.cpp:472: void std::__function::__policy_invoker::__call_impl[abi:se190107]>(std::__function::__policy_storage const*) @ 0x000000001184cedd 10. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001184858b 11. /build/src/IO/ReadWriteBufferFromHTTP.cpp:465: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x000000001184bf0b 12. /build/src/IO/ReadBuffer.h:60: DB::ReadBuffer::next() @ 0x000000000a148c7b 13. /build/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) @ 0x0000000011849fb2 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]>&)>&, 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&) @ 0x0000000011841980 15. /build/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) @ 0x000000001621208e 16. /build/src/Storages/StorageReplicatedMergeTree.cpp:5228: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl[abi:se190107] const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000015f9a5fe 17. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000015ed8bfd 18. /build/src/Storages/StorageReplicatedMergeTree.cpp:2514: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x0000000015ec9aab 19. /build/src/Storages/StorageReplicatedMergeTree.cpp:2349: DB::StorageReplicatedMergeTree::executeLogEntry(DB::ReplicatedMergeTreeLogEntry&) @ 0x0000000015eba91b 20. /build/src/Storages/StorageReplicatedMergeTree.cpp:3876: bool std::__function::__policy_invoker&)>::__call_impl[abi:se190107])::$_1, bool (std::shared_ptr&)>>(std::__function::__policy_storage const*, std::shared_ptr&) @ 0x0000000015f9837e 21. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000165d6fc3 22. /build/src/Storages/StorageReplicatedMergeTree.cpp:3872: DB::StorageReplicatedMergeTree::processQueueEntry(std::shared_ptr) @ 0x0000000015efc18a 23. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001624c1b2 24. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000162f9c70 25. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x00000000162fa55a 26. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc6653 27. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000000fccc4c3 28. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc3d92 29. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fcca080 30. ? @ 0x00007fbc6213eac3 31. ? @ 0x00007fbc621d0850 (version 25.3.6.10636.altinitytest (altinity build)) 2025.07.28 12:01:47.139836 [ 3968 ] {} test_13.rmt2 (7f9b740d-015c-470e-8cc6-8ba33be0dc63): auto DB::StorageReplicatedMergeTree::processQueueEntry(ReplicatedMergeTreeQueue::SelectedEntryPtr)::(anonymous class)::operator()(LogEntryPtr &) const: Code: 86. DB::HTTPException: Received error from remote server http://146b4357c08d:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Ftest%2F01165%2Ftest_13%2Frmt%2Freplicas%2F1&part=20250728_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.6.10636.altinitytest (altinity build)) '. (RECEIVED_ERROR_FROM_REMOTE_IO_SERVER), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.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 const&, int&&, String const&, unsigned long&&, String const&) @ 0x000000000feda8d9 4. /build/src/IO/HTTPCommon.cpp:104: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x000000000feda6e2 5. /build/src/IO/HTTPCommon.cpp:93: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x000000000feda537 6. /build/src/IO/ReadWriteBufferFromHTTP.cpp:277: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x000000001184a4c4 7. /build/src/IO/ReadWriteBufferFromHTTP.cpp:285: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x000000001184a615 8. /build/src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x000000001184ae59 9. /build/src/IO/ReadWriteBufferFromHTTP.cpp:472: void std::__function::__policy_invoker::__call_impl[abi:se190107]>(std::__function::__policy_storage const*) @ 0x000000001184cedd 10. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001184858b 11. /build/src/IO/ReadWriteBufferFromHTTP.cpp:465: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x000000001184bf0b 12. /build/src/IO/ReadBuffer.h:60: DB::ReadBuffer::next() @ 0x000000000a148c7b 13. /build/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) @ 0x0000000011849fb2 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]>&)>&, 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&) @ 0x0000000011841980 15. /build/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) @ 0x000000001621208e 16. /build/src/Storages/StorageReplicatedMergeTree.cpp:5228: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl[abi:se190107] const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000015f9a5fe 17. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000015ed8bfd 18. /build/src/Storages/StorageReplicatedMergeTree.cpp:2514: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x0000000015ec9aab 19. /build/src/Storages/StorageReplicatedMergeTree.cpp:2349: DB::StorageReplicatedMergeTree::executeLogEntry(DB::ReplicatedMergeTreeLogEntry&) @ 0x0000000015eba91b 20. /build/src/Storages/StorageReplicatedMergeTree.cpp:3876: bool std::__function::__policy_invoker&)>::__call_impl[abi:se190107])::$_1, bool (std::shared_ptr&)>>(std::__function::__policy_storage const*, std::shared_ptr&) @ 0x0000000015f9837e 21. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000165d6fc3 22. /build/src/Storages/StorageReplicatedMergeTree.cpp:3872: DB::StorageReplicatedMergeTree::processQueueEntry(std::shared_ptr) @ 0x0000000015efc18a 23. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001624c1b2 24. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000162f9c70 25. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x00000000162fa55a 26. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc6653 27. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000000fccc4c3 28. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc3d92 29. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fcca080 30. ? @ 0x00007fbc6213eac3 31. ? @ 0x00007fbc621d0850 (version 25.3.6.10636.altinitytest (altinity build)) 2025.07.28 12:01:47.645666 [ 3971 ] {} test_13.rmt2 (7f9b740d-015c-470e-8cc6-8ba33be0dc63): auto DB::StorageReplicatedMergeTree::processQueueEntry(ReplicatedMergeTreeQueue::SelectedEntryPtr)::(anonymous class)::operator()(LogEntryPtr &) const: Code: 86. DB::HTTPException: Received error from remote server http://146b4357c08d:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Ftest%2F01165%2Ftest_13%2Frmt%2Freplicas%2F1&part=20250728_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.6.10636.altinitytest (altinity build)) '. (RECEIVED_ERROR_FROM_REMOTE_IO_SERVER), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.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 const&, int&&, String const&, unsigned long&&, String const&) @ 0x000000000feda8d9 4. /build/src/IO/HTTPCommon.cpp:104: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x000000000feda6e2 5. /build/src/IO/HTTPCommon.cpp:93: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x000000000feda537 6. /build/src/IO/ReadWriteBufferFromHTTP.cpp:277: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x000000001184a4c4 7. /build/src/IO/ReadWriteBufferFromHTTP.cpp:285: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x000000001184a615 8. /build/src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x000000001184ae59 9. /build/src/IO/ReadWriteBufferFromHTTP.cpp:472: void std::__function::__policy_invoker::__call_impl[abi:se190107]>(std::__function::__policy_storage const*) @ 0x000000001184cedd 10. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001184858b 11. /build/src/IO/ReadWriteBufferFromHTTP.cpp:465: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x000000001184bf0b 12. /build/src/IO/ReadBuffer.h:60: DB::ReadBuffer::next() @ 0x000000000a148c7b 13. /build/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) @ 0x0000000011849fb2 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]>&)>&, 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&) @ 0x0000000011841980 15. /build/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) @ 0x000000001621208e 16. /build/src/Storages/StorageReplicatedMergeTree.cpp:5228: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl[abi:se190107] const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000015f9a5fe 17. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000015ed8bfd 18. /build/src/Storages/StorageReplicatedMergeTree.cpp:2514: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x0000000015ec9aab 19. /build/src/Storages/StorageReplicatedMergeTree.cpp:2349: DB::StorageReplicatedMergeTree::executeLogEntry(DB::ReplicatedMergeTreeLogEntry&) @ 0x0000000015eba91b 20. /build/src/Storages/StorageReplicatedMergeTree.cpp:3876: bool std::__function::__policy_invoker&)>::__call_impl[abi:se190107])::$_1, bool (std::shared_ptr&)>>(std::__function::__policy_storage const*, std::shared_ptr&) @ 0x0000000015f9837e 21. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000165d6fc3 22. /build/src/Storages/StorageReplicatedMergeTree.cpp:3872: DB::StorageReplicatedMergeTree::processQueueEntry(std::shared_ptr) @ 0x0000000015efc18a 23. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001624c1b2 24. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000162f9c70 25. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x00000000162fa55a 26. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc6653 27. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000000fccc4c3 28. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc3d92 29. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fcca080 30. ? @ 0x00007fbc6213eac3 31. ? @ 0x00007fbc621d0850 (version 25.3.6.10636.altinitytest (altinity build)) 2025.07.28 12:01:48.405299 [ 3972 ] {} test_13.rmt2 (7f9b740d-015c-470e-8cc6-8ba33be0dc63): auto DB::StorageReplicatedMergeTree::processQueueEntry(ReplicatedMergeTreeQueue::SelectedEntryPtr)::(anonymous class)::operator()(LogEntryPtr &) const: Code: 86. DB::HTTPException: Received error from remote server http://146b4357c08d:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Ftest%2F01165%2Ftest_13%2Frmt%2Freplicas%2F1&part=20250728_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.6.10636.altinitytest (altinity build)) '. (RECEIVED_ERROR_FROM_REMOTE_IO_SERVER), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.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 const&, int&&, String const&, unsigned long&&, String const&) @ 0x000000000feda8d9 4. /build/src/IO/HTTPCommon.cpp:104: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x000000000feda6e2 5. /build/src/IO/HTTPCommon.cpp:93: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x000000000feda537 6. /build/src/IO/ReadWriteBufferFromHTTP.cpp:277: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x000000001184a4c4 7. /build/src/IO/ReadWriteBufferFromHTTP.cpp:285: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x000000001184a615 8. /build/src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x000000001184ae59 9. /build/src/IO/ReadWriteBufferFromHTTP.cpp:472: void std::__function::__policy_invoker::__call_impl[abi:se190107]>(std::__function::__policy_storage const*) @ 0x000000001184cedd 10. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001184858b 11. /build/src/IO/ReadWriteBufferFromHTTP.cpp:465: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x000000001184bf0b 12. /build/src/IO/ReadBuffer.h:60: DB::ReadBuffer::next() @ 0x000000000a148c7b 13. /build/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) @ 0x0000000011849fb2 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]>&)>&, 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&) @ 0x0000000011841980 15. /build/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) @ 0x000000001621208e 16. /build/src/Storages/StorageReplicatedMergeTree.cpp:5228: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl[abi:se190107] const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000015f9a5fe 17. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000015ed8bfd 18. /build/src/Storages/StorageReplicatedMergeTree.cpp:2514: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x0000000015ec9aab 19. /build/src/Storages/StorageReplicatedMergeTree.cpp:2349: DB::StorageReplicatedMergeTree::executeLogEntry(DB::ReplicatedMergeTreeLogEntry&) @ 0x0000000015eba91b 20. /build/src/Storages/StorageReplicatedMergeTree.cpp:3876: bool std::__function::__policy_invoker&)>::__call_impl[abi:se190107])::$_1, bool (std::shared_ptr&)>>(std::__function::__policy_storage const*, std::shared_ptr&) @ 0x0000000015f9837e 21. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000165d6fc3 22. /build/src/Storages/StorageReplicatedMergeTree.cpp:3872: DB::StorageReplicatedMergeTree::processQueueEntry(std::shared_ptr) @ 0x0000000015efc18a 23. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001624c1b2 24. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000162f9c70 25. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x00000000162fa55a 26. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc6653 27. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000000fccc4c3 28. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc3d92 29. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fcca080 30. ? @ 0x00007fbc6213eac3 31. ? @ 0x00007fbc621d0850 (version 25.3.6.10636.altinitytest (altinity build)) 2025.07.28 12:01:48.715400 [ 3967 ] {} test_13.rmt2 (7f9b740d-015c-470e-8cc6-8ba33be0dc63): auto DB::StorageReplicatedMergeTree::processQueueEntry(ReplicatedMergeTreeQueue::SelectedEntryPtr)::(anonymous class)::operator()(LogEntryPtr &) const: Code: 86. DB::HTTPException: Received error from remote server http://146b4357c08d:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Ftest%2F01165%2Ftest_13%2Frmt%2Freplicas%2F1&part=20250728_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.6.10636.altinitytest (altinity build)) '. (RECEIVED_ERROR_FROM_REMOTE_IO_SERVER), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.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 const&, int&&, String const&, unsigned long&&, String const&) @ 0x000000000feda8d9 4. /build/src/IO/HTTPCommon.cpp:104: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x000000000feda6e2 5. /build/src/IO/HTTPCommon.cpp:93: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x000000000feda537 6. /build/src/IO/ReadWriteBufferFromHTTP.cpp:277: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x000000001184a4c4 7. /build/src/IO/ReadWriteBufferFromHTTP.cpp:285: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x000000001184a615 8. /build/src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x000000001184ae59 9. /build/src/IO/ReadWriteBufferFromHTTP.cpp:472: void std::__function::__policy_invoker::__call_impl[abi:se190107]>(std::__function::__policy_storage const*) @ 0x000000001184cedd 10. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001184858b 11. /build/src/IO/ReadWriteBufferFromHTTP.cpp:465: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x000000001184bf0b 12. /build/src/IO/ReadBuffer.h:60: DB::ReadBuffer::next() @ 0x000000000a148c7b 13. /build/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) @ 0x0000000011849fb2 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]>&)>&, 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&) @ 0x0000000011841980 15. /build/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) @ 0x000000001621208e 16. /build/src/Storages/StorageReplicatedMergeTree.cpp:5228: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl[abi:se190107] const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000015f9a5fe 17. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000015ed8bfd 18. /build/src/Storages/StorageReplicatedMergeTree.cpp:2514: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x0000000015ec9aab 19. /build/src/Storages/StorageReplicatedMergeTree.cpp:2349: DB::StorageReplicatedMergeTree::executeLogEntry(DB::ReplicatedMergeTreeLogEntry&) @ 0x0000000015eba91b 20. /build/src/Storages/StorageReplicatedMergeTree.cpp:3876: bool std::__function::__policy_invoker&)>::__call_impl[abi:se190107])::$_1, bool (std::shared_ptr&)>>(std::__function::__policy_storage const*, std::shared_ptr&) @ 0x0000000015f9837e 21. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000165d6fc3 22. /build/src/Storages/StorageReplicatedMergeTree.cpp:3872: DB::StorageReplicatedMergeTree::processQueueEntry(std::shared_ptr) @ 0x0000000015efc18a 23. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001624c1b2 24. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000162f9c70 25. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x00000000162fa55a 26. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc6653 27. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000000fccc4c3 28. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc3d92 29. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fcca080 30. ? @ 0x00007fbc6213eac3 31. ? @ 0x00007fbc621d0850 (version 25.3.6.10636.altinitytest (altinity build)) 2025.07.28 12:01:48.859100 [ 17371 ] {e02f372f-e4d4-434b-a957-2ef686809a2e} executeQuery: Code: 452. DB::Exception: Setting allow_experimental_object_type should not be changed. (SETTING_CONSTRAINT_VIOLATION) (version 25.3.6.10636.altinitytest (altinity build)) (from [::1]:60258) (comment: 01825_type_json_wide_parts_merge.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. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x000000000c25bc4b 4. /build/src/Access/SettingsConstraints.cpp:343: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000138596e3 5. /build/src/Access/SettingsConstraints.cpp:300: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000013858faf 6. /build/src/Access/SettingsConstraints.cpp:194: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges const&, DB::SettingSource) const @ 0x00000000138591b3 7. /build/src/Interpreters/Context.cpp:2722: DB::Context::checkSettingsConstraints(DB::SettingsChanges const&, DB::SettingSource) @ 0x0000000014436509 8. /build/src/Interpreters/InterpreterSetQuery.cpp:28: DB::InterpreterSetQuery::execute() @ 0x00000000149e240a 9. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88dc9 10. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 11. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 12. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 13. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 14. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 16. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 17. ? @ 0x00007fbc6213eac3 18. ? @ 0x00007fbc621d0850 2025.07.28 12:01:48.867715 [ 17371 ] {} 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. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x000000000c25bc4b 4. /build/src/Access/SettingsConstraints.cpp:343: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000138596e3 5. /build/src/Access/SettingsConstraints.cpp:300: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000013858faf 6. /build/src/Access/SettingsConstraints.cpp:194: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges const&, DB::SettingSource) const @ 0x00000000138591b3 7. /build/src/Interpreters/Context.cpp:2722: DB::Context::checkSettingsConstraints(DB::SettingsChanges const&, DB::SettingSource) @ 0x0000000014436509 8. /build/src/Interpreters/InterpreterSetQuery.cpp:28: DB::InterpreterSetQuery::execute() @ 0x00000000149e240a 9. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88dc9 10. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 11. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 12. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 13. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 14. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 16. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 17. ? @ 0x00007fbc6213eac3 18. ? @ 0x00007fbc621d0850 2025.07.28 12:01:49.291597 [ 3976 ] {} test_13.rmt2 (7f9b740d-015c-470e-8cc6-8ba33be0dc63): auto DB::StorageReplicatedMergeTree::processQueueEntry(ReplicatedMergeTreeQueue::SelectedEntryPtr)::(anonymous class)::operator()(LogEntryPtr &) const: Code: 86. DB::HTTPException: Received error from remote server http://146b4357c08d:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Ftest%2F01165%2Ftest_13%2Frmt%2Freplicas%2F1&part=20250728_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.6.10636.altinitytest (altinity build)) '. (RECEIVED_ERROR_FROM_REMOTE_IO_SERVER), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.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 const&, int&&, String const&, unsigned long&&, String const&) @ 0x000000000feda8d9 4. /build/src/IO/HTTPCommon.cpp:104: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x000000000feda6e2 5. /build/src/IO/HTTPCommon.cpp:93: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x000000000feda537 6. /build/src/IO/ReadWriteBufferFromHTTP.cpp:277: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x000000001184a4c4 7. /build/src/IO/ReadWriteBufferFromHTTP.cpp:285: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x000000001184a615 8. /build/src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x000000001184ae59 9. /build/src/IO/ReadWriteBufferFromHTTP.cpp:472: void std::__function::__policy_invoker::__call_impl[abi:se190107]>(std::__function::__policy_storage const*) @ 0x000000001184cedd 10. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001184858b 11. /build/src/IO/ReadWriteBufferFromHTTP.cpp:465: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x000000001184bf0b 12. /build/src/IO/ReadBuffer.h:60: DB::ReadBuffer::next() @ 0x000000000a148c7b 13. /build/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) @ 0x0000000011849fb2 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]>&)>&, 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&) @ 0x0000000011841980 15. /build/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) @ 0x000000001621208e 16. /build/src/Storages/StorageReplicatedMergeTree.cpp:5228: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl[abi:se190107] const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000015f9a5fe 17. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000015ed8bfd 18. /build/src/Storages/StorageReplicatedMergeTree.cpp:2514: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x0000000015ec9aab 19. /build/src/Storages/StorageReplicatedMergeTree.cpp:2349: DB::StorageReplicatedMergeTree::executeLogEntry(DB::ReplicatedMergeTreeLogEntry&) @ 0x0000000015eba91b 20. /build/src/Storages/StorageReplicatedMergeTree.cpp:3876: bool std::__function::__policy_invoker&)>::__call_impl[abi:se190107])::$_1, bool (std::shared_ptr&)>>(std::__function::__policy_storage const*, std::shared_ptr&) @ 0x0000000015f9837e 21. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000165d6fc3 22. /build/src/Storages/StorageReplicatedMergeTree.cpp:3872: DB::StorageReplicatedMergeTree::processQueueEntry(std::shared_ptr) @ 0x0000000015efc18a 23. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001624c1b2 24. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000162f9c70 25. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x00000000162fa55a 26. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc6653 27. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000000fccc4c3 28. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc3d92 29. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fcca080 30. ? @ 0x00007fbc6213eac3 31. ? @ 0x00007fbc621d0850 (version 25.3.6.10636.altinitytest (altinity build)) 2025.07.28 12:01:49.814560 [ 3965 ] {} test_13.rmt2 (7f9b740d-015c-470e-8cc6-8ba33be0dc63): auto DB::StorageReplicatedMergeTree::processQueueEntry(ReplicatedMergeTreeQueue::SelectedEntryPtr)::(anonymous class)::operator()(LogEntryPtr &) const: Code: 86. DB::HTTPException: Received error from remote server http://146b4357c08d:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Ftest%2F01165%2Ftest_13%2Frmt%2Freplicas%2F1&part=20250728_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.6.10636.altinitytest (altinity build)) '. (RECEIVED_ERROR_FROM_REMOTE_IO_SERVER), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.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 const&, int&&, String const&, unsigned long&&, String const&) @ 0x000000000feda8d9 4. /build/src/IO/HTTPCommon.cpp:104: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x000000000feda6e2 5. /build/src/IO/HTTPCommon.cpp:93: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x000000000feda537 6. /build/src/IO/ReadWriteBufferFromHTTP.cpp:277: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x000000001184a4c4 7. /build/src/IO/ReadWriteBufferFromHTTP.cpp:285: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x000000001184a615 8. /build/src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x000000001184ae59 9. /build/src/IO/ReadWriteBufferFromHTTP.cpp:472: void std::__function::__policy_invoker::__call_impl[abi:se190107]>(std::__function::__policy_storage const*) @ 0x000000001184cedd 10. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001184858b 11. /build/src/IO/ReadWriteBufferFromHTTP.cpp:465: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x000000001184bf0b 12. /build/src/IO/ReadBuffer.h:60: DB::ReadBuffer::next() @ 0x000000000a148c7b 13. /build/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) @ 0x0000000011849fb2 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]>&)>&, 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&) @ 0x0000000011841980 15. /build/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) @ 0x000000001621208e 16. /build/src/Storages/StorageReplicatedMergeTree.cpp:5228: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl[abi:se190107] const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000015f9a5fe 17. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000015ed8bfd 18. /build/src/Storages/StorageReplicatedMergeTree.cpp:2514: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x0000000015ec9aab 19. /build/src/Storages/StorageReplicatedMergeTree.cpp:2349: DB::StorageReplicatedMergeTree::executeLogEntry(DB::ReplicatedMergeTreeLogEntry&) @ 0x0000000015eba91b 20. /build/src/Storages/StorageReplicatedMergeTree.cpp:3876: bool std::__function::__policy_invoker&)>::__call_impl[abi:se190107])::$_1, bool (std::shared_ptr&)>>(std::__function::__policy_storage const*, std::shared_ptr&) @ 0x0000000015f9837e 21. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000165d6fc3 22. /build/src/Storages/StorageReplicatedMergeTree.cpp:3872: DB::StorageReplicatedMergeTree::processQueueEntry(std::shared_ptr) @ 0x0000000015efc18a 23. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001624c1b2 24. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000162f9c70 25. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x00000000162fa55a 26. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc6653 27. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000000fccc4c3 28. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc3d92 29. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fcca080 30. ? @ 0x00007fbc6213eac3 31. ? @ 0x00007fbc621d0850 (version 25.3.6.10636.altinitytest (altinity build)) 2025.07.28 12:01:50.036100 [ 3962 ] {} test_13.rmt2 (7f9b740d-015c-470e-8cc6-8ba33be0dc63): auto DB::StorageReplicatedMergeTree::processQueueEntry(ReplicatedMergeTreeQueue::SelectedEntryPtr)::(anonymous class)::operator()(LogEntryPtr &) const: Code: 86. DB::HTTPException: Received error from remote server http://146b4357c08d:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Ftest%2F01165%2Ftest_13%2Frmt%2Freplicas%2F1&part=20250728_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.6.10636.altinitytest (altinity build)) '. (RECEIVED_ERROR_FROM_REMOTE_IO_SERVER), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.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 const&, int&&, String const&, unsigned long&&, String const&) @ 0x000000000feda8d9 4. /build/src/IO/HTTPCommon.cpp:104: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x000000000feda6e2 5. /build/src/IO/HTTPCommon.cpp:93: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x000000000feda537 6. /build/src/IO/ReadWriteBufferFromHTTP.cpp:277: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x000000001184a4c4 7. /build/src/IO/ReadWriteBufferFromHTTP.cpp:285: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x000000001184a615 8. /build/src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x000000001184ae59 9. /build/src/IO/ReadWriteBufferFromHTTP.cpp:472: void std::__function::__policy_invoker::__call_impl[abi:se190107]>(std::__function::__policy_storage const*) @ 0x000000001184cedd 10. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001184858b 11. /build/src/IO/ReadWriteBufferFromHTTP.cpp:465: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x000000001184bf0b 12. /build/src/IO/ReadBuffer.h:60: DB::ReadBuffer::next() @ 0x000000000a148c7b 13. /build/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) @ 0x0000000011849fb2 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]>&)>&, 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&) @ 0x0000000011841980 15. /build/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) @ 0x000000001621208e 16. /build/src/Storages/StorageReplicatedMergeTree.cpp:5228: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl[abi:se190107] const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000015f9a5fe 17. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000015ed8bfd 18. /build/src/Storages/StorageReplicatedMergeTree.cpp:2514: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x0000000015ec9aab 19. /build/src/Storages/StorageReplicatedMergeTree.cpp:2349: DB::StorageReplicatedMergeTree::executeLogEntry(DB::ReplicatedMergeTreeLogEntry&) @ 0x0000000015eba91b 20. /build/src/Storages/StorageReplicatedMergeTree.cpp:3876: bool std::__function::__policy_invoker&)>::__call_impl[abi:se190107])::$_1, bool (std::shared_ptr&)>>(std::__function::__policy_storage const*, std::shared_ptr&) @ 0x0000000015f9837e 21. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000165d6fc3 22. /build/src/Storages/StorageReplicatedMergeTree.cpp:3872: DB::StorageReplicatedMergeTree::processQueueEntry(std::shared_ptr) @ 0x0000000015efc18a 23. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001624c1b2 24. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000162f9c70 25. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x00000000162fa55a 26. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc6653 27. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000000fccc4c3 28. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc3d92 29. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fcca080 30. ? @ 0x00007fbc6213eac3 31. ? @ 0x00007fbc621d0850 (version 25.3.6.10636.altinitytest (altinity build)) 2025.07.28 12:01:50.237971 [ 3963 ] {} test_13.rmt2 (7f9b740d-015c-470e-8cc6-8ba33be0dc63): auto DB::StorageReplicatedMergeTree::processQueueEntry(ReplicatedMergeTreeQueue::SelectedEntryPtr)::(anonymous class)::operator()(LogEntryPtr &) const: Code: 86. DB::HTTPException: Received error from remote server http://146b4357c08d:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Ftest%2F01165%2Ftest_13%2Frmt%2Freplicas%2F1&part=20250728_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.6.10636.altinitytest (altinity build)) '. (RECEIVED_ERROR_FROM_REMOTE_IO_SERVER), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.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 const&, int&&, String const&, unsigned long&&, String const&) @ 0x000000000feda8d9 4. /build/src/IO/HTTPCommon.cpp:104: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x000000000feda6e2 5. /build/src/IO/HTTPCommon.cpp:93: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x000000000feda537 6. /build/src/IO/ReadWriteBufferFromHTTP.cpp:277: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x000000001184a4c4 7. /build/src/IO/ReadWriteBufferFromHTTP.cpp:285: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x000000001184a615 8. /build/src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x000000001184ae59 9. /build/src/IO/ReadWriteBufferFromHTTP.cpp:472: void std::__function::__policy_invoker::__call_impl[abi:se190107]>(std::__function::__policy_storage const*) @ 0x000000001184cedd 10. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001184858b 11. /build/src/IO/ReadWriteBufferFromHTTP.cpp:465: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x000000001184bf0b 12. /build/src/IO/ReadBuffer.h:60: DB::ReadBuffer::next() @ 0x000000000a148c7b 13. /build/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) @ 0x0000000011849fb2 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]>&)>&, 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&) @ 0x0000000011841980 15. /build/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) @ 0x000000001621208e 16. /build/src/Storages/StorageReplicatedMergeTree.cpp:5228: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl[abi:se190107] const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000015f9a5fe 17. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000015ed8bfd 18. /build/src/Storages/StorageReplicatedMergeTree.cpp:2514: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x0000000015ec9aab 19. /build/src/Storages/StorageReplicatedMergeTree.cpp:2349: DB::StorageReplicatedMergeTree::executeLogEntry(DB::ReplicatedMergeTreeLogEntry&) @ 0x0000000015eba91b 20. /build/src/Storages/StorageReplicatedMergeTree.cpp:3876: bool std::__function::__policy_invoker&)>::__call_impl[abi:se190107])::$_1, bool (std::shared_ptr&)>>(std::__function::__policy_storage const*, std::shared_ptr&) @ 0x0000000015f9837e 21. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000165d6fc3 22. /build/src/Storages/StorageReplicatedMergeTree.cpp:3872: DB::StorageReplicatedMergeTree::processQueueEntry(std::shared_ptr) @ 0x0000000015efc18a 23. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001624c1b2 24. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000162f9c70 25. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x00000000162fa55a 26. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc6653 27. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000000fccc4c3 28. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc3d92 29. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fcca080 30. ? @ 0x00007fbc6213eac3 31. ? @ 0x00007fbc621d0850 (version 25.3.6.10636.altinitytest (altinity build)) 2025.07.28 12:01:50.852112 [ 3965 ] {} test_13.rmt2 (7f9b740d-015c-470e-8cc6-8ba33be0dc63): auto DB::StorageReplicatedMergeTree::processQueueEntry(ReplicatedMergeTreeQueue::SelectedEntryPtr)::(anonymous class)::operator()(LogEntryPtr &) const: Code: 86. DB::HTTPException: Received error from remote server http://146b4357c08d:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Ftest%2F01165%2Ftest_13%2Frmt%2Freplicas%2F1&part=20250728_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.6.10636.altinitytest (altinity build)) '. (RECEIVED_ERROR_FROM_REMOTE_IO_SERVER), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.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 const&, int&&, String const&, unsigned long&&, String const&) @ 0x000000000feda8d9 4. /build/src/IO/HTTPCommon.cpp:104: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x000000000feda6e2 5. /build/src/IO/HTTPCommon.cpp:93: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x000000000feda537 6. /build/src/IO/ReadWriteBufferFromHTTP.cpp:277: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x000000001184a4c4 7. /build/src/IO/ReadWriteBufferFromHTTP.cpp:285: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x000000001184a615 8. /build/src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x000000001184ae59 9. /build/src/IO/ReadWriteBufferFromHTTP.cpp:472: void std::__function::__policy_invoker::__call_impl[abi:se190107]>(std::__function::__policy_storage const*) @ 0x000000001184cedd 10. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001184858b 11. /build/src/IO/ReadWriteBufferFromHTTP.cpp:465: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x000000001184bf0b 12. /build/src/IO/ReadBuffer.h:60: DB::ReadBuffer::next() @ 0x000000000a148c7b 13. /build/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) @ 0x0000000011849fb2 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]>&)>&, 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&) @ 0x0000000011841980 15. /build/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) @ 0x000000001621208e 16. /build/src/Storages/StorageReplicatedMergeTree.cpp:5228: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl[abi:se190107] const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000015f9a5fe 17. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000015ed8bfd 18. /build/src/Storages/StorageReplicatedMergeTree.cpp:2514: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x0000000015ec9aab 19. /build/src/Storages/StorageReplicatedMergeTree.cpp:2349: DB::StorageReplicatedMergeTree::executeLogEntry(DB::ReplicatedMergeTreeLogEntry&) @ 0x0000000015eba91b 20. /build/src/Storages/StorageReplicatedMergeTree.cpp:3876: bool std::__function::__policy_invoker&)>::__call_impl[abi:se190107])::$_1, bool (std::shared_ptr&)>>(std::__function::__policy_storage const*, std::shared_ptr&) @ 0x0000000015f9837e 21. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000165d6fc3 22. /build/src/Storages/StorageReplicatedMergeTree.cpp:3872: DB::StorageReplicatedMergeTree::processQueueEntry(std::shared_ptr) @ 0x0000000015efc18a 23. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001624c1b2 24. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000162f9c70 25. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x00000000162fa55a 26. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc6653 27. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000000fccc4c3 28. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc3d92 29. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fcca080 30. ? @ 0x00007fbc6213eac3 31. ? @ 0x00007fbc621d0850 (version 25.3.6.10636.altinitytest (altinity build)) 2025.07.28 12:01:51.164838 [ 3974 ] {} test_13.rmt2 (7f9b740d-015c-470e-8cc6-8ba33be0dc63): auto DB::StorageReplicatedMergeTree::processQueueEntry(ReplicatedMergeTreeQueue::SelectedEntryPtr)::(anonymous class)::operator()(LogEntryPtr &) const: Code: 86. DB::HTTPException: Received error from remote server http://146b4357c08d:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Ftest%2F01165%2Ftest_13%2Frmt%2Freplicas%2F1&part=20250728_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.6.10636.altinitytest (altinity build)) '. (RECEIVED_ERROR_FROM_REMOTE_IO_SERVER), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.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 const&, int&&, String const&, unsigned long&&, String const&) @ 0x000000000feda8d9 4. /build/src/IO/HTTPCommon.cpp:104: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x000000000feda6e2 5. /build/src/IO/HTTPCommon.cpp:93: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x000000000feda537 6. /build/src/IO/ReadWriteBufferFromHTTP.cpp:277: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x000000001184a4c4 7. /build/src/IO/ReadWriteBufferFromHTTP.cpp:285: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x000000001184a615 8. /build/src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x000000001184ae59 9. /build/src/IO/ReadWriteBufferFromHTTP.cpp:472: void std::__function::__policy_invoker::__call_impl[abi:se190107]>(std::__function::__policy_storage const*) @ 0x000000001184cedd 10. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001184858b 11. /build/src/IO/ReadWriteBufferFromHTTP.cpp:465: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x000000001184bf0b 12. /build/src/IO/ReadBuffer.h:60: DB::ReadBuffer::next() @ 0x000000000a148c7b 13. /build/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) @ 0x0000000011849fb2 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]>&)>&, 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&) @ 0x0000000011841980 15. /build/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) @ 0x000000001621208e 16. /build/src/Storages/StorageReplicatedMergeTree.cpp:5228: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl[abi:se190107] const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000015f9a5fe 17. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000015ed8bfd 18. /build/src/Storages/StorageReplicatedMergeTree.cpp:2514: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x0000000015ec9aab 19. /build/src/Storages/StorageReplicatedMergeTree.cpp:2349: DB::StorageReplicatedMergeTree::executeLogEntry(DB::ReplicatedMergeTreeLogEntry&) @ 0x0000000015eba91b 20. /build/src/Storages/StorageReplicatedMergeTree.cpp:3876: bool std::__function::__policy_invoker&)>::__call_impl[abi:se190107])::$_1, bool (std::shared_ptr&)>>(std::__function::__policy_storage const*, std::shared_ptr&) @ 0x0000000015f9837e 21. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000165d6fc3 22. /build/src/Storages/StorageReplicatedMergeTree.cpp:3872: DB::StorageReplicatedMergeTree::processQueueEntry(std::shared_ptr) @ 0x0000000015efc18a 23. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001624c1b2 24. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000162f9c70 25. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x00000000162fa55a 26. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc6653 27. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000000fccc4c3 28. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc3d92 29. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fcca080 30. ? @ 0x00007fbc6213eac3 31. ? @ 0x00007fbc621d0850 (version 25.3.6.10636.altinitytest (altinity build)) 2025.07.28 12:01:51.324147 [ 3970 ] {} test_13.rmt2 (7f9b740d-015c-470e-8cc6-8ba33be0dc63): auto DB::StorageReplicatedMergeTree::processQueueEntry(ReplicatedMergeTreeQueue::SelectedEntryPtr)::(anonymous class)::operator()(LogEntryPtr &) const: Code: 86. DB::HTTPException: Received error from remote server http://146b4357c08d:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Ftest%2F01165%2Ftest_13%2Frmt%2Freplicas%2F1&part=20250728_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.6.10636.altinitytest (altinity build)) '. (RECEIVED_ERROR_FROM_REMOTE_IO_SERVER), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.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 const&, int&&, String const&, unsigned long&&, String const&) @ 0x000000000feda8d9 4. /build/src/IO/HTTPCommon.cpp:104: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x000000000feda6e2 5. /build/src/IO/HTTPCommon.cpp:93: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x000000000feda537 6. /build/src/IO/ReadWriteBufferFromHTTP.cpp:277: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x000000001184a4c4 7. /build/src/IO/ReadWriteBufferFromHTTP.cpp:285: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x000000001184a615 8. /build/src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x000000001184ae59 9. /build/src/IO/ReadWriteBufferFromHTTP.cpp:472: void std::__function::__policy_invoker::__call_impl[abi:se190107]>(std::__function::__policy_storage const*) @ 0x000000001184cedd 10. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001184858b 11. /build/src/IO/ReadWriteBufferFromHTTP.cpp:465: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x000000001184bf0b 12. /build/src/IO/ReadBuffer.h:60: DB::ReadBuffer::next() @ 0x000000000a148c7b 13. /build/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) @ 0x0000000011849fb2 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]>&)>&, 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&) @ 0x0000000011841980 15. /build/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) @ 0x000000001621208e 16. /build/src/Storages/StorageReplicatedMergeTree.cpp:5228: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl[abi:se190107] const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000015f9a5fe 17. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000015ed8bfd 18. /build/src/Storages/StorageReplicatedMergeTree.cpp:2514: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x0000000015ec9aab 19. /build/src/Storages/StorageReplicatedMergeTree.cpp:2349: DB::StorageReplicatedMergeTree::executeLogEntry(DB::ReplicatedMergeTreeLogEntry&) @ 0x0000000015eba91b 20. /build/src/Storages/StorageReplicatedMergeTree.cpp:3876: bool std::__function::__policy_invoker&)>::__call_impl[abi:se190107])::$_1, bool (std::shared_ptr&)>>(std::__function::__policy_storage const*, std::shared_ptr&) @ 0x0000000015f9837e 21. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000165d6fc3 22. /build/src/Storages/StorageReplicatedMergeTree.cpp:3872: DB::StorageReplicatedMergeTree::processQueueEntry(std::shared_ptr) @ 0x0000000015efc18a 23. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001624c1b2 24. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000162f9c70 25. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x00000000162fa55a 26. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc6653 27. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000000fccc4c3 28. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc3d92 29. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fcca080 30. ? @ 0x00007fbc6213eac3 31. ? @ 0x00007fbc621d0850 (version 25.3.6.10636.altinitytest (altinity build)) 2025.07.28 12:01:51.479867 [ 4963 ] {} 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. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception>&, String>(int, FormatStringHelperImpl>&>::type, std::type_identity::type>, std::basic_string_view>&, String&&) @ 0x000000001385a5eb 4. /build/src/Access/SettingsConstraints.cpp:376: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000013859b18 5. /build/src/Access/SettingsConstraints.cpp:300: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000013858faf 6. /build/src/Access/SettingsConstraints.cpp:209: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000013859223 7. /build/src/Interpreters/Context.cpp:2690: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000014436134 8. /build/src/Interpreters/Context.cpp:2729: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x000000001443662b 9. /build/src/Server/HTTPHandler.cpp:457: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000001686d165 10. /build/src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x0000000016870807 11. /build/src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x0000000016907e99 12. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 13. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 14. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 15. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 16. ? @ 0x00007fbc6213eac3 17. ? @ 0x00007fbc621d0850 (version 25.3.6.10636.altinitytest (altinity build)) 2025.07.28 12:01:52.176560 [ 3969 ] {} test_13.rmt2 (7f9b740d-015c-470e-8cc6-8ba33be0dc63): auto DB::StorageReplicatedMergeTree::processQueueEntry(ReplicatedMergeTreeQueue::SelectedEntryPtr)::(anonymous class)::operator()(LogEntryPtr &) const: Code: 86. DB::HTTPException: Received error from remote server http://146b4357c08d:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Ftest%2F01165%2Ftest_13%2Frmt%2Freplicas%2F1&part=20250728_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.6.10636.altinitytest (altinity build)) '. (RECEIVED_ERROR_FROM_REMOTE_IO_SERVER), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.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 const&, int&&, String const&, unsigned long&&, String const&) @ 0x000000000feda8d9 4. /build/src/IO/HTTPCommon.cpp:104: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x000000000feda6e2 5. /build/src/IO/HTTPCommon.cpp:93: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x000000000feda537 6. /build/src/IO/ReadWriteBufferFromHTTP.cpp:277: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x000000001184a4c4 7. /build/src/IO/ReadWriteBufferFromHTTP.cpp:285: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x000000001184a615 8. /build/src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x000000001184ae59 9. /build/src/IO/ReadWriteBufferFromHTTP.cpp:472: void std::__function::__policy_invoker::__call_impl[abi:se190107]>(std::__function::__policy_storage const*) @ 0x000000001184cedd 10. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001184858b 11. /build/src/IO/ReadWriteBufferFromHTTP.cpp:465: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x000000001184bf0b 12. /build/src/IO/ReadBuffer.h:60: DB::ReadBuffer::next() @ 0x000000000a148c7b 13. /build/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) @ 0x0000000011849fb2 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]>&)>&, 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&) @ 0x0000000011841980 15. /build/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) @ 0x000000001621208e 16. /build/src/Storages/StorageReplicatedMergeTree.cpp:5228: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl[abi:se190107] const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000015f9a5fe 17. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000015ed8bfd 18. /build/src/Storages/StorageReplicatedMergeTree.cpp:2514: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x0000000015ec9aab 19. /build/src/Storages/StorageReplicatedMergeTree.cpp:2349: DB::StorageReplicatedMergeTree::executeLogEntry(DB::ReplicatedMergeTreeLogEntry&) @ 0x0000000015eba91b 20. /build/src/Storages/StorageReplicatedMergeTree.cpp:3876: bool std::__function::__policy_invoker&)>::__call_impl[abi:se190107])::$_1, bool (std::shared_ptr&)>>(std::__function::__policy_storage const*, std::shared_ptr&) @ 0x0000000015f9837e 21. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000165d6fc3 22. /build/src/Storages/StorageReplicatedMergeTree.cpp:3872: DB::StorageReplicatedMergeTree::processQueueEntry(std::shared_ptr) @ 0x0000000015efc18a 23. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001624c1b2 24. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000162f9c70 25. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x00000000162fa55a 26. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc6653 27. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000000fccc4c3 28. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc3d92 29. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fcca080 30. ? @ 0x00007fbc6213eac3 31. ? @ 0x00007fbc621d0850 (version 25.3.6.10636.altinitytest (altinity build)) 2025.07.28 12:01:52.530751 [ 3971 ] {} test_13.rmt2 (7f9b740d-015c-470e-8cc6-8ba33be0dc63): auto DB::StorageReplicatedMergeTree::processQueueEntry(ReplicatedMergeTreeQueue::SelectedEntryPtr)::(anonymous class)::operator()(LogEntryPtr &) const: Code: 86. DB::HTTPException: Received error from remote server http://146b4357c08d:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Ftest%2F01165%2Ftest_13%2Frmt%2Freplicas%2F1&part=20250728_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.6.10636.altinitytest (altinity build)) '. (RECEIVED_ERROR_FROM_REMOTE_IO_SERVER), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.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 const&, int&&, String const&, unsigned long&&, String const&) @ 0x000000000feda8d9 4. /build/src/IO/HTTPCommon.cpp:104: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x000000000feda6e2 5. /build/src/IO/HTTPCommon.cpp:93: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x000000000feda537 6. /build/src/IO/ReadWriteBufferFromHTTP.cpp:277: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x000000001184a4c4 7. /build/src/IO/ReadWriteBufferFromHTTP.cpp:285: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x000000001184a615 8. /build/src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x000000001184ae59 9. /build/src/IO/ReadWriteBufferFromHTTP.cpp:472: void std::__function::__policy_invoker::__call_impl[abi:se190107]>(std::__function::__policy_storage const*) @ 0x000000001184cedd 10. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001184858b 11. /build/src/IO/ReadWriteBufferFromHTTP.cpp:465: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x000000001184bf0b 12. /build/src/IO/ReadBuffer.h:60: DB::ReadBuffer::next() @ 0x000000000a148c7b 13. /build/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) @ 0x0000000011849fb2 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]>&)>&, 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&) @ 0x0000000011841980 15. /build/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) @ 0x000000001621208e 16. /build/src/Storages/StorageReplicatedMergeTree.cpp:5228: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl[abi:se190107] const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000015f9a5fe 17. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000015ed8bfd 18. /build/src/Storages/StorageReplicatedMergeTree.cpp:2514: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x0000000015ec9aab 19. /build/src/Storages/StorageReplicatedMergeTree.cpp:2349: DB::StorageReplicatedMergeTree::executeLogEntry(DB::ReplicatedMergeTreeLogEntry&) @ 0x0000000015eba91b 20. /build/src/Storages/StorageReplicatedMergeTree.cpp:3876: bool std::__function::__policy_invoker&)>::__call_impl[abi:se190107])::$_1, bool (std::shared_ptr&)>>(std::__function::__policy_storage const*, std::shared_ptr&) @ 0x0000000015f9837e 21. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000165d6fc3 22. /build/src/Storages/StorageReplicatedMergeTree.cpp:3872: DB::StorageReplicatedMergeTree::processQueueEntry(std::shared_ptr) @ 0x0000000015efc18a 23. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001624c1b2 24. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000162f9c70 25. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x00000000162fa55a 26. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc6653 27. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000000fccc4c3 28. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc3d92 29. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fcca080 30. ? @ 0x00007fbc6213eac3 31. ? @ 0x00007fbc621d0850 (version 25.3.6.10636.altinitytest (altinity build)) 2025.07.28 12:01:52.878996 [ 3961 ] {} test_13.rmt2 (7f9b740d-015c-470e-8cc6-8ba33be0dc63): auto DB::StorageReplicatedMergeTree::processQueueEntry(ReplicatedMergeTreeQueue::SelectedEntryPtr)::(anonymous class)::operator()(LogEntryPtr &) const: Code: 86. DB::HTTPException: Received error from remote server http://146b4357c08d:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Ftest%2F01165%2Ftest_13%2Frmt%2Freplicas%2F1&part=20250728_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.6.10636.altinitytest (altinity build)) '. (RECEIVED_ERROR_FROM_REMOTE_IO_SERVER), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.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 const&, int&&, String const&, unsigned long&&, String const&) @ 0x000000000feda8d9 4. /build/src/IO/HTTPCommon.cpp:104: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x000000000feda6e2 5. /build/src/IO/HTTPCommon.cpp:93: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x000000000feda537 6. /build/src/IO/ReadWriteBufferFromHTTP.cpp:277: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x000000001184a4c4 7. /build/src/IO/ReadWriteBufferFromHTTP.cpp:285: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x000000001184a615 8. /build/src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x000000001184ae59 9. /build/src/IO/ReadWriteBufferFromHTTP.cpp:472: void std::__function::__policy_invoker::__call_impl[abi:se190107]>(std::__function::__policy_storage const*) @ 0x000000001184cedd 10. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001184858b 11. /build/src/IO/ReadWriteBufferFromHTTP.cpp:465: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x000000001184bf0b 12. /build/src/IO/ReadBuffer.h:60: DB::ReadBuffer::next() @ 0x000000000a148c7b 13. /build/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) @ 0x0000000011849fb2 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]>&)>&, 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&) @ 0x0000000011841980 15. /build/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) @ 0x000000001621208e 16. /build/src/Storages/StorageReplicatedMergeTree.cpp:5228: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl[abi:se190107] const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000015f9a5fe 17. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000015ed8bfd 18. /build/src/Storages/StorageReplicatedMergeTree.cpp:2514: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x0000000015ec9aab 19. /build/src/Storages/StorageReplicatedMergeTree.cpp:2349: DB::StorageReplicatedMergeTree::executeLogEntry(DB::ReplicatedMergeTreeLogEntry&) @ 0x0000000015eba91b 20. /build/src/Storages/StorageReplicatedMergeTree.cpp:3876: bool std::__function::__policy_invoker&)>::__call_impl[abi:se190107])::$_1, bool (std::shared_ptr&)>>(std::__function::__policy_storage const*, std::shared_ptr&) @ 0x0000000015f9837e 21. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000165d6fc3 22. /build/src/Storages/StorageReplicatedMergeTree.cpp:3872: DB::StorageReplicatedMergeTree::processQueueEntry(std::shared_ptr) @ 0x0000000015efc18a 23. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001624c1b2 24. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000162f9c70 25. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x00000000162fa55a 26. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc6653 27. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000000fccc4c3 28. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc3d92 29. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fcca080 30. ? @ 0x00007fbc6213eac3 31. ? @ 0x00007fbc621d0850 (version 25.3.6.10636.altinitytest (altinity build)) 2025.07.28 12:01:54.015148 [ 3967 ] {} test_13.rmt2 (7f9b740d-015c-470e-8cc6-8ba33be0dc63): auto DB::StorageReplicatedMergeTree::processQueueEntry(ReplicatedMergeTreeQueue::SelectedEntryPtr)::(anonymous class)::operator()(LogEntryPtr &) const: Code: 86. DB::HTTPException: Received error from remote server http://146b4357c08d:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Ftest%2F01165%2Ftest_13%2Frmt%2Freplicas%2F1&part=20250728_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.6.10636.altinitytest (altinity build)) '. (RECEIVED_ERROR_FROM_REMOTE_IO_SERVER), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.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 const&, int&&, String const&, unsigned long&&, String const&) @ 0x000000000feda8d9 4. /build/src/IO/HTTPCommon.cpp:104: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x000000000feda6e2 5. /build/src/IO/HTTPCommon.cpp:93: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x000000000feda537 6. /build/src/IO/ReadWriteBufferFromHTTP.cpp:277: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x000000001184a4c4 7. /build/src/IO/ReadWriteBufferFromHTTP.cpp:285: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x000000001184a615 8. /build/src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x000000001184ae59 9. /build/src/IO/ReadWriteBufferFromHTTP.cpp:472: void std::__function::__policy_invoker::__call_impl[abi:se190107]>(std::__function::__policy_storage const*) @ 0x000000001184cedd 10. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001184858b 11. /build/src/IO/ReadWriteBufferFromHTTP.cpp:465: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x000000001184bf0b 12. /build/src/IO/ReadBuffer.h:60: DB::ReadBuffer::next() @ 0x000000000a148c7b 13. /build/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) @ 0x0000000011849fb2 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]>&)>&, 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&) @ 0x0000000011841980 15. /build/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) @ 0x000000001621208e 16. /build/src/Storages/StorageReplicatedMergeTree.cpp:5228: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl[abi:se190107] const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000015f9a5fe 17. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000015ed8bfd 18. /build/src/Storages/StorageReplicatedMergeTree.cpp:2514: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x0000000015ec9aab 19. /build/src/Storages/StorageReplicatedMergeTree.cpp:2349: DB::StorageReplicatedMergeTree::executeLogEntry(DB::ReplicatedMergeTreeLogEntry&) @ 0x0000000015eba91b 20. /build/src/Storages/StorageReplicatedMergeTree.cpp:3876: bool std::__function::__policy_invoker&)>::__call_impl[abi:se190107])::$_1, bool (std::shared_ptr&)>>(std::__function::__policy_storage const*, std::shared_ptr&) @ 0x0000000015f9837e 21. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000165d6fc3 22. /build/src/Storages/StorageReplicatedMergeTree.cpp:3872: DB::StorageReplicatedMergeTree::processQueueEntry(std::shared_ptr) @ 0x0000000015efc18a 23. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001624c1b2 24. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000162f9c70 25. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x00000000162fa55a 26. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc6653 27. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000000fccc4c3 28. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc3d92 29. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fcca080 30. ? @ 0x00007fbc6213eac3 31. ? @ 0x00007fbc621d0850 (version 25.3.6.10636.altinitytest (altinity build)) 2025.07.28 12:01:54.706731 [ 3965 ] {} test_13.rmt2 (7f9b740d-015c-470e-8cc6-8ba33be0dc63): auto DB::StorageReplicatedMergeTree::processQueueEntry(ReplicatedMergeTreeQueue::SelectedEntryPtr)::(anonymous class)::operator()(LogEntryPtr &) const: Code: 86. DB::HTTPException: Received error from remote server http://146b4357c08d:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Ftest%2F01165%2Ftest_13%2Frmt%2Freplicas%2F1&part=20250728_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.6.10636.altinitytest (altinity build)) '. (RECEIVED_ERROR_FROM_REMOTE_IO_SERVER), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.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 const&, int&&, String const&, unsigned long&&, String const&) @ 0x000000000feda8d9 4. /build/src/IO/HTTPCommon.cpp:104: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x000000000feda6e2 5. /build/src/IO/HTTPCommon.cpp:93: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x000000000feda537 6. /build/src/IO/ReadWriteBufferFromHTTP.cpp:277: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x000000001184a4c4 7. /build/src/IO/ReadWriteBufferFromHTTP.cpp:285: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x000000001184a615 8. /build/src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x000000001184ae59 9. /build/src/IO/ReadWriteBufferFromHTTP.cpp:472: void std::__function::__policy_invoker::__call_impl[abi:se190107]>(std::__function::__policy_storage const*) @ 0x000000001184cedd 10. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001184858b 11. /build/src/IO/ReadWriteBufferFromHTTP.cpp:465: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x000000001184bf0b 12. /build/src/IO/ReadBuffer.h:60: DB::ReadBuffer::next() @ 0x000000000a148c7b 13. /build/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) @ 0x0000000011849fb2 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]>&)>&, 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&) @ 0x0000000011841980 15. /build/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) @ 0x000000001621208e 16. /build/src/Storages/StorageReplicatedMergeTree.cpp:5228: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl[abi:se190107] const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000015f9a5fe 17. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000015ed8bfd 18. /build/src/Storages/StorageReplicatedMergeTree.cpp:2514: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x0000000015ec9aab 19. /build/src/Storages/StorageReplicatedMergeTree.cpp:2349: DB::StorageReplicatedMergeTree::executeLogEntry(DB::ReplicatedMergeTreeLogEntry&) @ 0x0000000015eba91b 20. /build/src/Storages/StorageReplicatedMergeTree.cpp:3876: bool std::__function::__policy_invoker&)>::__call_impl[abi:se190107])::$_1, bool (std::shared_ptr&)>>(std::__function::__policy_storage const*, std::shared_ptr&) @ 0x0000000015f9837e 21. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000165d6fc3 22. /build/src/Storages/StorageReplicatedMergeTree.cpp:3872: DB::StorageReplicatedMergeTree::processQueueEntry(std::shared_ptr) @ 0x0000000015efc18a 23. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001624c1b2 24. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000162f9c70 25. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x00000000162fa55a 26. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc6653 27. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000000fccc4c3 28. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc3d92 29. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fcca080 30. ? @ 0x00007fbc6213eac3 31. ? @ 0x00007fbc621d0850 (version 25.3.6.10636.altinitytest (altinity build)) 2025.07.28 12:01:55.806464 [ 3968 ] {} test_13.rmt2 (7f9b740d-015c-470e-8cc6-8ba33be0dc63): auto DB::StorageReplicatedMergeTree::processQueueEntry(ReplicatedMergeTreeQueue::SelectedEntryPtr)::(anonymous class)::operator()(LogEntryPtr &) const: Code: 86. DB::HTTPException: Received error from remote server http://146b4357c08d:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Ftest%2F01165%2Ftest_13%2Frmt%2Freplicas%2F1&part=20250728_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.6.10636.altinitytest (altinity build)) '. (RECEIVED_ERROR_FROM_REMOTE_IO_SERVER), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.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 const&, int&&, String const&, unsigned long&&, String const&) @ 0x000000000feda8d9 4. /build/src/IO/HTTPCommon.cpp:104: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x000000000feda6e2 5. /build/src/IO/HTTPCommon.cpp:93: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x000000000feda537 6. /build/src/IO/ReadWriteBufferFromHTTP.cpp:277: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x000000001184a4c4 7. /build/src/IO/ReadWriteBufferFromHTTP.cpp:285: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x000000001184a615 8. /build/src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x000000001184ae59 9. /build/src/IO/ReadWriteBufferFromHTTP.cpp:472: void std::__function::__policy_invoker::__call_impl[abi:se190107]>(std::__function::__policy_storage const*) @ 0x000000001184cedd 10. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001184858b 11. /build/src/IO/ReadWriteBufferFromHTTP.cpp:465: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x000000001184bf0b 12. /build/src/IO/ReadBuffer.h:60: DB::ReadBuffer::next() @ 0x000000000a148c7b 13. /build/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) @ 0x0000000011849fb2 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]>&)>&, 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&) @ 0x0000000011841980 15. /build/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) @ 0x000000001621208e 16. /build/src/Storages/StorageReplicatedMergeTree.cpp:5228: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl[abi:se190107] const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000015f9a5fe 17. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000015ed8bfd 18. /build/src/Storages/StorageReplicatedMergeTree.cpp:2514: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x0000000015ec9aab 19. /build/src/Storages/StorageReplicatedMergeTree.cpp:2349: DB::StorageReplicatedMergeTree::executeLogEntry(DB::ReplicatedMergeTreeLogEntry&) @ 0x0000000015eba91b 20. /build/src/Storages/StorageReplicatedMergeTree.cpp:3876: bool std::__function::__policy_invoker&)>::__call_impl[abi:se190107])::$_1, bool (std::shared_ptr&)>>(std::__function::__policy_storage const*, std::shared_ptr&) @ 0x0000000015f9837e 21. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000165d6fc3 22. /build/src/Storages/StorageReplicatedMergeTree.cpp:3872: DB::StorageReplicatedMergeTree::processQueueEntry(std::shared_ptr) @ 0x0000000015efc18a 23. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001624c1b2 24. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000162f9c70 25. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x00000000162fa55a 26. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc6653 27. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000000fccc4c3 28. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc3d92 29. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fcca080 30. ? @ 0x00007fbc6213eac3 31. ? @ 0x00007fbc621d0850 (version 25.3.6.10636.altinitytest (altinity build)) 2025.07.28 12:01:56.485982 [ 3972 ] {} test_13.rmt2 (7f9b740d-015c-470e-8cc6-8ba33be0dc63): auto DB::StorageReplicatedMergeTree::processQueueEntry(ReplicatedMergeTreeQueue::SelectedEntryPtr)::(anonymous class)::operator()(LogEntryPtr &) const: Code: 86. DB::HTTPException: Received error from remote server http://146b4357c08d:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Ftest%2F01165%2Ftest_13%2Frmt%2Freplicas%2F1&part=20250728_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.6.10636.altinitytest (altinity build)) '. (RECEIVED_ERROR_FROM_REMOTE_IO_SERVER), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.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 const&, int&&, String const&, unsigned long&&, String const&) @ 0x000000000feda8d9 4. /build/src/IO/HTTPCommon.cpp:104: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x000000000feda6e2 5. /build/src/IO/HTTPCommon.cpp:93: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x000000000feda537 6. /build/src/IO/ReadWriteBufferFromHTTP.cpp:277: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x000000001184a4c4 7. /build/src/IO/ReadWriteBufferFromHTTP.cpp:285: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x000000001184a615 8. /build/src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x000000001184ae59 9. /build/src/IO/ReadWriteBufferFromHTTP.cpp:472: void std::__function::__policy_invoker::__call_impl[abi:se190107]>(std::__function::__policy_storage const*) @ 0x000000001184cedd 10. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001184858b 11. /build/src/IO/ReadWriteBufferFromHTTP.cpp:465: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x000000001184bf0b 12. /build/src/IO/ReadBuffer.h:60: DB::ReadBuffer::next() @ 0x000000000a148c7b 13. /build/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) @ 0x0000000011849fb2 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]>&)>&, 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&) @ 0x0000000011841980 15. /build/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) @ 0x000000001621208e 16. /build/src/Storages/StorageReplicatedMergeTree.cpp:5228: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl[abi:se190107] const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000015f9a5fe 17. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000015ed8bfd 18. /build/src/Storages/StorageReplicatedMergeTree.cpp:2514: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x0000000015ec9aab 19. /build/src/Storages/StorageReplicatedMergeTree.cpp:2349: DB::StorageReplicatedMergeTree::executeLogEntry(DB::ReplicatedMergeTreeLogEntry&) @ 0x0000000015eba91b 20. /build/src/Storages/StorageReplicatedMergeTree.cpp:3876: bool std::__function::__policy_invoker&)>::__call_impl[abi:se190107])::$_1, bool (std::shared_ptr&)>>(std::__function::__policy_storage const*, std::shared_ptr&) @ 0x0000000015f9837e 21. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000165d6fc3 22. /build/src/Storages/StorageReplicatedMergeTree.cpp:3872: DB::StorageReplicatedMergeTree::processQueueEntry(std::shared_ptr) @ 0x0000000015efc18a 23. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001624c1b2 24. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000162f9c70 25. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x00000000162fa55a 26. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc6653 27. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000000fccc4c3 28. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc3d92 29. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fcca080 30. ? @ 0x00007fbc6213eac3 31. ? @ 0x00007fbc621d0850 (version 25.3.6.10636.altinitytest (altinity build)) 2025.07.28 12:01:56.987424 [ 3962 ] {} test_13.rmt2 (7f9b740d-015c-470e-8cc6-8ba33be0dc63): auto DB::StorageReplicatedMergeTree::processQueueEntry(ReplicatedMergeTreeQueue::SelectedEntryPtr)::(anonymous class)::operator()(LogEntryPtr &) const: Code: 86. DB::HTTPException: Received error from remote server http://146b4357c08d:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Ftest%2F01165%2Ftest_13%2Frmt%2Freplicas%2F1&part=20250728_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.6.10636.altinitytest (altinity build)) '. (RECEIVED_ERROR_FROM_REMOTE_IO_SERVER), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.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 const&, int&&, String const&, unsigned long&&, String const&) @ 0x000000000feda8d9 4. /build/src/IO/HTTPCommon.cpp:104: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x000000000feda6e2 5. /build/src/IO/HTTPCommon.cpp:93: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x000000000feda537 6. /build/src/IO/ReadWriteBufferFromHTTP.cpp:277: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x000000001184a4c4 7. /build/src/IO/ReadWriteBufferFromHTTP.cpp:285: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x000000001184a615 8. /build/src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x000000001184ae59 9. /build/src/IO/ReadWriteBufferFromHTTP.cpp:472: void std::__function::__policy_invoker::__call_impl[abi:se190107]>(std::__function::__policy_storage const*) @ 0x000000001184cedd 10. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001184858b 11. /build/src/IO/ReadWriteBufferFromHTTP.cpp:465: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x000000001184bf0b 12. /build/src/IO/ReadBuffer.h:60: DB::ReadBuffer::next() @ 0x000000000a148c7b 13. /build/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) @ 0x0000000011849fb2 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]>&)>&, 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&) @ 0x0000000011841980 15. /build/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) @ 0x000000001621208e 16. /build/src/Storages/StorageReplicatedMergeTree.cpp:5228: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl[abi:se190107] const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000015f9a5fe 17. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000015ed8bfd 18. /build/src/Storages/StorageReplicatedMergeTree.cpp:2514: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x0000000015ec9aab 19. /build/src/Storages/StorageReplicatedMergeTree.cpp:2349: DB::StorageReplicatedMergeTree::executeLogEntry(DB::ReplicatedMergeTreeLogEntry&) @ 0x0000000015eba91b 20. /build/src/Storages/StorageReplicatedMergeTree.cpp:3876: bool std::__function::__policy_invoker&)>::__call_impl[abi:se190107])::$_1, bool (std::shared_ptr&)>>(std::__function::__policy_storage const*, std::shared_ptr&) @ 0x0000000015f9837e 21. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000165d6fc3 22. /build/src/Storages/StorageReplicatedMergeTree.cpp:3872: DB::StorageReplicatedMergeTree::processQueueEntry(std::shared_ptr) @ 0x0000000015efc18a 23. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001624c1b2 24. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000162f9c70 25. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x00000000162fa55a 26. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc6653 27. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000000fccc4c3 28. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc3d92 29. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fcca080 30. ? @ 0x00007fbc6213eac3 31. ? @ 0x00007fbc621d0850 (version 25.3.6.10636.altinitytest (altinity build)) 2025.07.28 12:01:57.837383 [ 3963 ] {} test_13.rmt2 (7f9b740d-015c-470e-8cc6-8ba33be0dc63): auto DB::StorageReplicatedMergeTree::processQueueEntry(ReplicatedMergeTreeQueue::SelectedEntryPtr)::(anonymous class)::operator()(LogEntryPtr &) const: Code: 86. DB::HTTPException: Received error from remote server http://146b4357c08d:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Ftest%2F01165%2Ftest_13%2Frmt%2Freplicas%2F1&part=20250728_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.6.10636.altinitytest (altinity build)) '. (RECEIVED_ERROR_FROM_REMOTE_IO_SERVER), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.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 const&, int&&, String const&, unsigned long&&, String const&) @ 0x000000000feda8d9 4. /build/src/IO/HTTPCommon.cpp:104: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x000000000feda6e2 5. /build/src/IO/HTTPCommon.cpp:93: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x000000000feda537 6. /build/src/IO/ReadWriteBufferFromHTTP.cpp:277: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x000000001184a4c4 7. /build/src/IO/ReadWriteBufferFromHTTP.cpp:285: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x000000001184a615 8. /build/src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x000000001184ae59 9. /build/src/IO/ReadWriteBufferFromHTTP.cpp:472: void std::__function::__policy_invoker::__call_impl[abi:se190107]>(std::__function::__policy_storage const*) @ 0x000000001184cedd 10. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001184858b 11. /build/src/IO/ReadWriteBufferFromHTTP.cpp:465: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x000000001184bf0b 12. /build/src/IO/ReadBuffer.h:60: DB::ReadBuffer::next() @ 0x000000000a148c7b 13. /build/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) @ 0x0000000011849fb2 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]>&)>&, 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&) @ 0x0000000011841980 15. /build/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) @ 0x000000001621208e 16. /build/src/Storages/StorageReplicatedMergeTree.cpp:5228: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl[abi:se190107] const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000015f9a5fe 17. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000015ed8bfd 18. /build/src/Storages/StorageReplicatedMergeTree.cpp:2514: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x0000000015ec9aab 19. /build/src/Storages/StorageReplicatedMergeTree.cpp:2349: DB::StorageReplicatedMergeTree::executeLogEntry(DB::ReplicatedMergeTreeLogEntry&) @ 0x0000000015eba91b 20. /build/src/Storages/StorageReplicatedMergeTree.cpp:3876: bool std::__function::__policy_invoker&)>::__call_impl[abi:se190107])::$_1, bool (std::shared_ptr&)>>(std::__function::__policy_storage const*, std::shared_ptr&) @ 0x0000000015f9837e 21. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000165d6fc3 22. /build/src/Storages/StorageReplicatedMergeTree.cpp:3872: DB::StorageReplicatedMergeTree::processQueueEntry(std::shared_ptr) @ 0x0000000015efc18a 23. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001624c1b2 24. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000162f9c70 25. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x00000000162fa55a 26. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc6653 27. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000000fccc4c3 28. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc3d92 29. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fcca080 30. ? @ 0x00007fbc6213eac3 31. ? @ 0x00007fbc621d0850 (version 25.3.6.10636.altinitytest (altinity build)) 2025.07.28 12:01:58.932702 [ 3970 ] {} test_13.rmt2 (7f9b740d-015c-470e-8cc6-8ba33be0dc63): auto DB::StorageReplicatedMergeTree::processQueueEntry(ReplicatedMergeTreeQueue::SelectedEntryPtr)::(anonymous class)::operator()(LogEntryPtr &) const: Code: 86. DB::HTTPException: Received error from remote server http://146b4357c08d:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Ftest%2F01165%2Ftest_13%2Frmt%2Freplicas%2F1&part=20250728_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.6.10636.altinitytest (altinity build)) '. (RECEIVED_ERROR_FROM_REMOTE_IO_SERVER), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.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 const&, int&&, String const&, unsigned long&&, String const&) @ 0x000000000feda8d9 4. /build/src/IO/HTTPCommon.cpp:104: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x000000000feda6e2 5. /build/src/IO/HTTPCommon.cpp:93: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x000000000feda537 6. /build/src/IO/ReadWriteBufferFromHTTP.cpp:277: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x000000001184a4c4 7. /build/src/IO/ReadWriteBufferFromHTTP.cpp:285: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x000000001184a615 8. /build/src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x000000001184ae59 9. /build/src/IO/ReadWriteBufferFromHTTP.cpp:472: void std::__function::__policy_invoker::__call_impl[abi:se190107]>(std::__function::__policy_storage const*) @ 0x000000001184cedd 10. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001184858b 11. /build/src/IO/ReadWriteBufferFromHTTP.cpp:465: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x000000001184bf0b 12. /build/src/IO/ReadBuffer.h:60: DB::ReadBuffer::next() @ 0x000000000a148c7b 13. /build/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) @ 0x0000000011849fb2 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]>&)>&, 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&) @ 0x0000000011841980 15. /build/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) @ 0x000000001621208e 16. /build/src/Storages/StorageReplicatedMergeTree.cpp:5228: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl[abi:se190107] const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000015f9a5fe 17. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000015ed8bfd 18. /build/src/Storages/StorageReplicatedMergeTree.cpp:2514: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x0000000015ec9aab 19. /build/src/Storages/StorageReplicatedMergeTree.cpp:2349: DB::StorageReplicatedMergeTree::executeLogEntry(DB::ReplicatedMergeTreeLogEntry&) @ 0x0000000015eba91b 20. /build/src/Storages/StorageReplicatedMergeTree.cpp:3876: bool std::__function::__policy_invoker&)>::__call_impl[abi:se190107])::$_1, bool (std::shared_ptr&)>>(std::__function::__policy_storage const*, std::shared_ptr&) @ 0x0000000015f9837e 21. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000165d6fc3 22. /build/src/Storages/StorageReplicatedMergeTree.cpp:3872: DB::StorageReplicatedMergeTree::processQueueEntry(std::shared_ptr) @ 0x0000000015efc18a 23. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001624c1b2 24. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000162f9c70 25. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x00000000162fa55a 26. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc6653 27. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000000fccc4c3 28. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc3d92 29. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fcca080 30. ? @ 0x00007fbc6213eac3 31. ? @ 0x00007fbc621d0850 (version 25.3.6.10636.altinitytest (altinity build)) 2025.07.28 12:01:59.132524 [ 3960 ] {} test_13.rmt2 (7f9b740d-015c-470e-8cc6-8ba33be0dc63): auto DB::StorageReplicatedMergeTree::processQueueEntry(ReplicatedMergeTreeQueue::SelectedEntryPtr)::(anonymous class)::operator()(LogEntryPtr &) const: Code: 86. DB::HTTPException: Received error from remote server http://146b4357c08d:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Ftest%2F01165%2Ftest_13%2Frmt%2Freplicas%2F1&part=20250728_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.6.10636.altinitytest (altinity build)) '. (RECEIVED_ERROR_FROM_REMOTE_IO_SERVER), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.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 const&, int&&, String const&, unsigned long&&, String const&) @ 0x000000000feda8d9 4. /build/src/IO/HTTPCommon.cpp:104: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x000000000feda6e2 5. /build/src/IO/HTTPCommon.cpp:93: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x000000000feda537 6. /build/src/IO/ReadWriteBufferFromHTTP.cpp:277: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x000000001184a4c4 7. /build/src/IO/ReadWriteBufferFromHTTP.cpp:285: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x000000001184a615 8. /build/src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x000000001184ae59 9. /build/src/IO/ReadWriteBufferFromHTTP.cpp:472: void std::__function::__policy_invoker::__call_impl[abi:se190107]>(std::__function::__policy_storage const*) @ 0x000000001184cedd 10. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001184858b 11. /build/src/IO/ReadWriteBufferFromHTTP.cpp:465: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x000000001184bf0b 12. /build/src/IO/ReadBuffer.h:60: DB::ReadBuffer::next() @ 0x000000000a148c7b 13. /build/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) @ 0x0000000011849fb2 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]>&)>&, 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&) @ 0x0000000011841980 15. /build/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) @ 0x000000001621208e 16. /build/src/Storages/StorageReplicatedMergeTree.cpp:5228: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl[abi:se190107] const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000015f9a5fe 17. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000015ed8bfd 18. /build/src/Storages/StorageReplicatedMergeTree.cpp:2514: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x0000000015ec9aab 19. /build/src/Storages/StorageReplicatedMergeTree.cpp:2349: DB::StorageReplicatedMergeTree::executeLogEntry(DB::ReplicatedMergeTreeLogEntry&) @ 0x0000000015eba91b 20. /build/src/Storages/StorageReplicatedMergeTree.cpp:3876: bool std::__function::__policy_invoker&)>::__call_impl[abi:se190107])::$_1, bool (std::shared_ptr&)>>(std::__function::__policy_storage const*, std::shared_ptr&) @ 0x0000000015f9837e 21. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000165d6fc3 22. /build/src/Storages/StorageReplicatedMergeTree.cpp:3872: DB::StorageReplicatedMergeTree::processQueueEntry(std::shared_ptr) @ 0x0000000015efc18a 23. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001624c1b2 24. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000162f9c70 25. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x00000000162fa55a 26. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc6653 27. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000000fccc4c3 28. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc3d92 29. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fcca080 30. ? @ 0x00007fbc6213eac3 31. ? @ 0x00007fbc621d0850 (version 25.3.6.10636.altinitytest (altinity build)) 2025.07.28 12:01:59.751298 [ 3967 ] {} test_13.rmt2 (7f9b740d-015c-470e-8cc6-8ba33be0dc63): auto DB::StorageReplicatedMergeTree::processQueueEntry(ReplicatedMergeTreeQueue::SelectedEntryPtr)::(anonymous class)::operator()(LogEntryPtr &) const: Code: 86. DB::HTTPException: Received error from remote server http://146b4357c08d:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Ftest%2F01165%2Ftest_13%2Frmt%2Freplicas%2F1&part=20250728_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.6.10636.altinitytest (altinity build)) '. (RECEIVED_ERROR_FROM_REMOTE_IO_SERVER), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.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 const&, int&&, String const&, unsigned long&&, String const&) @ 0x000000000feda8d9 4. /build/src/IO/HTTPCommon.cpp:104: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x000000000feda6e2 5. /build/src/IO/HTTPCommon.cpp:93: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x000000000feda537 6. /build/src/IO/ReadWriteBufferFromHTTP.cpp:277: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x000000001184a4c4 7. /build/src/IO/ReadWriteBufferFromHTTP.cpp:285: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x000000001184a615 8. /build/src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x000000001184ae59 9. /build/src/IO/ReadWriteBufferFromHTTP.cpp:472: void std::__function::__policy_invoker::__call_impl[abi:se190107]>(std::__function::__policy_storage const*) @ 0x000000001184cedd 10. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001184858b 11. /build/src/IO/ReadWriteBufferFromHTTP.cpp:465: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x000000001184bf0b 12. /build/src/IO/ReadBuffer.h:60: DB::ReadBuffer::next() @ 0x000000000a148c7b 13. /build/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) @ 0x0000000011849fb2 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]>&)>&, 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&) @ 0x0000000011841980 15. /build/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) @ 0x000000001621208e 16. /build/src/Storages/StorageReplicatedMergeTree.cpp:5228: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl[abi:se190107] const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000015f9a5fe 17. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000015ed8bfd 18. /build/src/Storages/StorageReplicatedMergeTree.cpp:2514: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x0000000015ec9aab 19. /build/src/Storages/StorageReplicatedMergeTree.cpp:2349: DB::StorageReplicatedMergeTree::executeLogEntry(DB::ReplicatedMergeTreeLogEntry&) @ 0x0000000015eba91b 20. /build/src/Storages/StorageReplicatedMergeTree.cpp:3876: bool std::__function::__policy_invoker&)>::__call_impl[abi:se190107])::$_1, bool (std::shared_ptr&)>>(std::__function::__policy_storage const*, std::shared_ptr&) @ 0x0000000015f9837e 21. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000165d6fc3 22. /build/src/Storages/StorageReplicatedMergeTree.cpp:3872: DB::StorageReplicatedMergeTree::processQueueEntry(std::shared_ptr) @ 0x0000000015efc18a 23. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001624c1b2 24. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000162f9c70 25. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x00000000162fa55a 26. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc6653 27. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000000fccc4c3 28. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc3d92 29. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fcca080 30. ? @ 0x00007fbc6213eac3 31. ? @ 0x00007fbc621d0850 (version 25.3.6.10636.altinitytest (altinity build)) 2025.07.28 12:02:00.430098 [ 3972 ] {} test_13.rmt2 (7f9b740d-015c-470e-8cc6-8ba33be0dc63): auto DB::StorageReplicatedMergeTree::processQueueEntry(ReplicatedMergeTreeQueue::SelectedEntryPtr)::(anonymous class)::operator()(LogEntryPtr &) const: Code: 86. DB::HTTPException: Received error from remote server http://146b4357c08d:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Ftest%2F01165%2Ftest_13%2Frmt%2Freplicas%2F1&part=20250728_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.6.10636.altinitytest (altinity build)) '. (RECEIVED_ERROR_FROM_REMOTE_IO_SERVER), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.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 const&, int&&, String const&, unsigned long&&, String const&) @ 0x000000000feda8d9 4. /build/src/IO/HTTPCommon.cpp:104: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x000000000feda6e2 5. /build/src/IO/HTTPCommon.cpp:93: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x000000000feda537 6. /build/src/IO/ReadWriteBufferFromHTTP.cpp:277: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x000000001184a4c4 7. /build/src/IO/ReadWriteBufferFromHTTP.cpp:285: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x000000001184a615 8. /build/src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x000000001184ae59 9. /build/src/IO/ReadWriteBufferFromHTTP.cpp:472: void std::__function::__policy_invoker::__call_impl[abi:se190107]>(std::__function::__policy_storage const*) @ 0x000000001184cedd 10. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001184858b 11. /build/src/IO/ReadWriteBufferFromHTTP.cpp:465: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x000000001184bf0b 12. /build/src/IO/ReadBuffer.h:60: DB::ReadBuffer::next() @ 0x000000000a148c7b 13. /build/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) @ 0x0000000011849fb2 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]>&)>&, 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&) @ 0x0000000011841980 15. /build/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) @ 0x000000001621208e 16. /build/src/Storages/StorageReplicatedMergeTree.cpp:5228: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl[abi:se190107] const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000015f9a5fe 17. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000015ed8bfd 18. /build/src/Storages/StorageReplicatedMergeTree.cpp:2514: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x0000000015ec9aab 19. /build/src/Storages/StorageReplicatedMergeTree.cpp:2349: DB::StorageReplicatedMergeTree::executeLogEntry(DB::ReplicatedMergeTreeLogEntry&) @ 0x0000000015eba91b 20. /build/src/Storages/StorageReplicatedMergeTree.cpp:3876: bool std::__function::__policy_invoker&)>::__call_impl[abi:se190107])::$_1, bool (std::shared_ptr&)>>(std::__function::__policy_storage const*, std::shared_ptr&) @ 0x0000000015f9837e 21. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000165d6fc3 22. /build/src/Storages/StorageReplicatedMergeTree.cpp:3872: DB::StorageReplicatedMergeTree::processQueueEntry(std::shared_ptr) @ 0x0000000015efc18a 23. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001624c1b2 24. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000162f9c70 25. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x00000000162fa55a 26. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc6653 27. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000000fccc4c3 28. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc3d92 29. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fcca080 30. ? @ 0x00007fbc6213eac3 31. ? @ 0x00007fbc621d0850 (version 25.3.6.10636.altinitytest (altinity build)) 2025.07.28 12:02:00.595634 [ 17203 ] {76a4a030-217c-42a9-8d84-265a06b5ff25} executeQuery: Code: 36. DB::Exception: Argument 'kafka_broker_list' must be a literal, get Function_equals (value: a = '1'). (BAD_ARGUMENTS) (version 25.3.6.10636.altinitytest (altinity build)) (from [::1]:39338) (comment: 03305_fix_kafka_table_with_kw_arguments.sql) (query 1, line 3) (in query: CREATE TABLE default.test ( `id` UInt32, `message` String ) ENGINE = Kafka(a = '1', 'clickhouse');), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, String&&, String&&) @ 0x000000001098ed2b 4. /build/src/Storages/checkAndGetLiteralArgument.cpp:25: String DB::checkAndGetLiteralArgument(std::shared_ptr const&, String const&) @ 0x0000000016051f87 5. /build/src/Storages/Kafka/StorageKafkaUtils.cpp:169: DB::registerStorageKafka(DB::StorageFactory&)::$_0::operator()(DB::StorageFactory::Arguments const&) const @ 0x000000001328b0b1 6. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000015d81ea2 7. /build/src/Interpreters/InterpreterCreateQuery.cpp:1945: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x00000000149009bb 8. /build/src/Interpreters/InterpreterCreateQuery.cpp:1743: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000148f9aa9 9. /build/src/Interpreters/InterpreterCreateQuery.cpp:2352: DB::InterpreterCreateQuery::execute() @ 0x0000000014905a41 10. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88dc9 11. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 12. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 13. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 14. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 15. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 16. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 17. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 18. ? @ 0x00007fbc6213eac3 19. ? @ 0x00007fbc621d0850 2025.07.28 12:02:00.599483 [ 17203 ] {} TCPHandler: Code: 36. DB::Exception: Argument 'kafka_broker_list' must be a literal, get Function_equals (value: a = '1'). (BAD_ARGUMENTS), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, String&&, String&&) @ 0x000000001098ed2b 4. /build/src/Storages/checkAndGetLiteralArgument.cpp:25: String DB::checkAndGetLiteralArgument(std::shared_ptr const&, String const&) @ 0x0000000016051f87 5. /build/src/Storages/Kafka/StorageKafkaUtils.cpp:169: DB::registerStorageKafka(DB::StorageFactory&)::$_0::operator()(DB::StorageFactory::Arguments const&) const @ 0x000000001328b0b1 6. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000015d81ea2 7. /build/src/Interpreters/InterpreterCreateQuery.cpp:1945: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x00000000149009bb 8. /build/src/Interpreters/InterpreterCreateQuery.cpp:1743: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000148f9aa9 9. /build/src/Interpreters/InterpreterCreateQuery.cpp:2352: DB::InterpreterCreateQuery::execute() @ 0x0000000014905a41 10. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88dc9 11. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 12. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 13. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 14. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 15. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 16. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 17. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 18. ? @ 0x00007fbc6213eac3 19. ? @ 0x00007fbc621d0850 2025.07.28 12:02:01.376143 [ 3976 ] {} test_13.rmt2 (7f9b740d-015c-470e-8cc6-8ba33be0dc63): auto DB::StorageReplicatedMergeTree::processQueueEntry(ReplicatedMergeTreeQueue::SelectedEntryPtr)::(anonymous class)::operator()(LogEntryPtr &) const: Code: 86. DB::HTTPException: Received error from remote server http://146b4357c08d:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Ftest%2F01165%2Ftest_13%2Frmt%2Freplicas%2F1&part=20250728_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.6.10636.altinitytest (altinity build)) '. (RECEIVED_ERROR_FROM_REMOTE_IO_SERVER), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.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 const&, int&&, String const&, unsigned long&&, String const&) @ 0x000000000feda8d9 4. /build/src/IO/HTTPCommon.cpp:104: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x000000000feda6e2 5. /build/src/IO/HTTPCommon.cpp:93: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x000000000feda537 6. /build/src/IO/ReadWriteBufferFromHTTP.cpp:277: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x000000001184a4c4 7. /build/src/IO/ReadWriteBufferFromHTTP.cpp:285: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x000000001184a615 8. /build/src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x000000001184ae59 9. /build/src/IO/ReadWriteBufferFromHTTP.cpp:472: void std::__function::__policy_invoker::__call_impl[abi:se190107]>(std::__function::__policy_storage const*) @ 0x000000001184cedd 10. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001184858b 11. /build/src/IO/ReadWriteBufferFromHTTP.cpp:465: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x000000001184bf0b 12. /build/src/IO/ReadBuffer.h:60: DB::ReadBuffer::next() @ 0x000000000a148c7b 13. /build/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) @ 0x0000000011849fb2 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]>&)>&, 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&) @ 0x0000000011841980 15. /build/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) @ 0x000000001621208e 16. /build/src/Storages/StorageReplicatedMergeTree.cpp:5228: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl[abi:se190107] const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000015f9a5fe 17. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000015ed8bfd 18. /build/src/Storages/StorageReplicatedMergeTree.cpp:2514: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x0000000015ec9aab 19. /build/src/Storages/StorageReplicatedMergeTree.cpp:2349: DB::StorageReplicatedMergeTree::executeLogEntry(DB::ReplicatedMergeTreeLogEntry&) @ 0x0000000015eba91b 20. /build/src/Storages/StorageReplicatedMergeTree.cpp:3876: bool std::__function::__policy_invoker&)>::__call_impl[abi:se190107])::$_1, bool (std::shared_ptr&)>>(std::__function::__policy_storage const*, std::shared_ptr&) @ 0x0000000015f9837e 21. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000165d6fc3 22. /build/src/Storages/StorageReplicatedMergeTree.cpp:3872: DB::StorageReplicatedMergeTree::processQueueEntry(std::shared_ptr) @ 0x0000000015efc18a 23. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001624c1b2 24. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000162f9c70 25. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x00000000162fa55a 26. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc6653 27. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000000fccc4c3 28. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc3d92 29. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fcca080 30. ? @ 0x00007fbc6213eac3 31. ? @ 0x00007fbc621d0850 (version 25.3.6.10636.altinitytest (altinity build)) 2025.07.28 12:02:01.711555 [ 3966 ] {} test_13.rmt2 (7f9b740d-015c-470e-8cc6-8ba33be0dc63): auto DB::StorageReplicatedMergeTree::processQueueEntry(ReplicatedMergeTreeQueue::SelectedEntryPtr)::(anonymous class)::operator()(LogEntryPtr &) const: Code: 86. DB::HTTPException: Received error from remote server http://146b4357c08d:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Ftest%2F01165%2Ftest_13%2Frmt%2Freplicas%2F1&part=20250728_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.6.10636.altinitytest (altinity build)) '. (RECEIVED_ERROR_FROM_REMOTE_IO_SERVER), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.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 const&, int&&, String const&, unsigned long&&, String const&) @ 0x000000000feda8d9 4. /build/src/IO/HTTPCommon.cpp:104: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x000000000feda6e2 5. /build/src/IO/HTTPCommon.cpp:93: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x000000000feda537 6. /build/src/IO/ReadWriteBufferFromHTTP.cpp:277: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x000000001184a4c4 7. /build/src/IO/ReadWriteBufferFromHTTP.cpp:285: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x000000001184a615 8. /build/src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x000000001184ae59 9. /build/src/IO/ReadWriteBufferFromHTTP.cpp:472: void std::__function::__policy_invoker::__call_impl[abi:se190107]>(std::__function::__policy_storage const*) @ 0x000000001184cedd 10. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001184858b 11. /build/src/IO/ReadWriteBufferFromHTTP.cpp:465: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x000000001184bf0b 12. /build/src/IO/ReadBuffer.h:60: DB::ReadBuffer::next() @ 0x000000000a148c7b 13. /build/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) @ 0x0000000011849fb2 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]>&)>&, 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&) @ 0x0000000011841980 15. /build/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) @ 0x000000001621208e 16. /build/src/Storages/StorageReplicatedMergeTree.cpp:5228: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl[abi:se190107] const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000015f9a5fe 17. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000015ed8bfd 18. /build/src/Storages/StorageReplicatedMergeTree.cpp:2514: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x0000000015ec9aab 19. /build/src/Storages/StorageReplicatedMergeTree.cpp:2349: DB::StorageReplicatedMergeTree::executeLogEntry(DB::ReplicatedMergeTreeLogEntry&) @ 0x0000000015eba91b 20. /build/src/Storages/StorageReplicatedMergeTree.cpp:3876: bool std::__function::__policy_invoker&)>::__call_impl[abi:se190107])::$_1, bool (std::shared_ptr&)>>(std::__function::__policy_storage const*, std::shared_ptr&) @ 0x0000000015f9837e 21. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000165d6fc3 22. /build/src/Storages/StorageReplicatedMergeTree.cpp:3872: DB::StorageReplicatedMergeTree::processQueueEntry(std::shared_ptr) @ 0x0000000015efc18a 23. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001624c1b2 24. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000162f9c70 25. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x00000000162fa55a 26. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc6653 27. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000000fccc4c3 28. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc3d92 29. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fcca080 30. ? @ 0x00007fbc6213eac3 31. ? @ 0x00007fbc621d0850 (version 25.3.6.10636.altinitytest (altinity build)) 2025.07.28 12:02:02.578255 [ 5879 ] {} TCPHandler: TCPHandler: Code: 81. DB::Exception: Database test_11 does not exist. Maybe you meant test_1?. (UNKNOWN_DATABASE), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000a06a8eb 4. /build/src/Interpreters/DatabaseCatalog.cpp:535: DB::DatabaseCatalog::assertDatabaseExists(String const&) const @ 0x00000000144f31f6 5. /build/src/Server/TCPHandler.cpp:342: DB::TCPHandler::runImpl() @ 0x00000000168e5a19 6. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 7. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 8. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 9. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 10. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 11. ? @ 0x00007fbc6213eac3 12. ? @ 0x00007fbc621d0850 (version 25.3.6.10636.altinitytest (altinity build)) 2025.07.28 12:02:02.578808 [ 5879 ] {} ServerErrorHandler: Code: 81. DB::Exception: Database test_11 does not exist. Maybe you meant test_1?. (UNKNOWN_DATABASE), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000a06a8eb 4. /build/src/Interpreters/DatabaseCatalog.cpp:535: DB::DatabaseCatalog::assertDatabaseExists(String const&) const @ 0x00000000144f31f6 5. /build/src/Server/TCPHandler.cpp:342: DB::TCPHandler::runImpl() @ 0x00000000168e5a19 6. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 7. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 8. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 9. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 10. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 11. ? @ 0x00007fbc6213eac3 12. ? @ 0x00007fbc621d0850 (version 25.3.6.10636.altinitytest (altinity build)) 2025.07.28 12:02:02.711849 [ 5879 ] {} TCPHandler: TCPHandler: Code: 81. DB::Exception: Database test_11 does not exist. Maybe you meant test_1?. (UNKNOWN_DATABASE), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000a06a8eb 4. /build/src/Interpreters/DatabaseCatalog.cpp:535: DB::DatabaseCatalog::assertDatabaseExists(String const&) const @ 0x00000000144f31f6 5. /build/src/Server/TCPHandler.cpp:342: DB::TCPHandler::runImpl() @ 0x00000000168e5a19 6. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 7. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 8. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 9. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 10. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 11. ? @ 0x00007fbc6213eac3 12. ? @ 0x00007fbc621d0850 (version 25.3.6.10636.altinitytest (altinity build)) 2025.07.28 12:02:02.712655 [ 5879 ] {} ServerErrorHandler: Code: 81. DB::Exception: Database test_11 does not exist. Maybe you meant test_1?. (UNKNOWN_DATABASE), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000a06a8eb 4. /build/src/Interpreters/DatabaseCatalog.cpp:535: DB::DatabaseCatalog::assertDatabaseExists(String const&) const @ 0x00000000144f31f6 5. /build/src/Server/TCPHandler.cpp:342: DB::TCPHandler::runImpl() @ 0x00000000168e5a19 6. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 7. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 8. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 9. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 10. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 11. ? @ 0x00007fbc6213eac3 12. ? @ 0x00007fbc621d0850 (version 25.3.6.10636.altinitytest (altinity build)) 2025.07.28 12:02:02.825678 [ 3962 ] {} test_13.rmt2 (7f9b740d-015c-470e-8cc6-8ba33be0dc63): auto DB::StorageReplicatedMergeTree::processQueueEntry(ReplicatedMergeTreeQueue::SelectedEntryPtr)::(anonymous class)::operator()(LogEntryPtr &) const: Code: 86. DB::HTTPException: Received error from remote server http://146b4357c08d:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Ftest%2F01165%2Ftest_13%2Frmt%2Freplicas%2F1&part=20250728_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.6.10636.altinitytest (altinity build)) '. (RECEIVED_ERROR_FROM_REMOTE_IO_SERVER), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.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 const&, int&&, String const&, unsigned long&&, String const&) @ 0x000000000feda8d9 4. /build/src/IO/HTTPCommon.cpp:104: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x000000000feda6e2 5. /build/src/IO/HTTPCommon.cpp:93: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x000000000feda537 6. /build/src/IO/ReadWriteBufferFromHTTP.cpp:277: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x000000001184a4c4 7. /build/src/IO/ReadWriteBufferFromHTTP.cpp:285: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x000000001184a615 8. /build/src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x000000001184ae59 9. /build/src/IO/ReadWriteBufferFromHTTP.cpp:472: void std::__function::__policy_invoker::__call_impl[abi:se190107]>(std::__function::__policy_storage const*) @ 0x000000001184cedd 10. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001184858b 11. /build/src/IO/ReadWriteBufferFromHTTP.cpp:465: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x000000001184bf0b 12. /build/src/IO/ReadBuffer.h:60: DB::ReadBuffer::next() @ 0x000000000a148c7b 13. /build/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) @ 0x0000000011849fb2 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]>&)>&, 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&) @ 0x0000000011841980 15. /build/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) @ 0x000000001621208e 16. /build/src/Storages/StorageReplicatedMergeTree.cpp:5228: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl[abi:se190107] const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000015f9a5fe 17. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000015ed8bfd 18. /build/src/Storages/StorageReplicatedMergeTree.cpp:2514: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x0000000015ec9aab 19. /build/src/Storages/StorageReplicatedMergeTree.cpp:2349: DB::StorageReplicatedMergeTree::executeLogEntry(DB::ReplicatedMergeTreeLogEntry&) @ 0x0000000015eba91b 20. /build/src/Storages/StorageReplicatedMergeTree.cpp:3876: bool std::__function::__policy_invoker&)>::__call_impl[abi:se190107])::$_1, bool (std::shared_ptr&)>>(std::__function::__policy_storage const*, std::shared_ptr&) @ 0x0000000015f9837e 21. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000165d6fc3 22. /build/src/Storages/StorageReplicatedMergeTree.cpp:3872: DB::StorageReplicatedMergeTree::processQueueEntry(std::shared_ptr) @ 0x0000000015efc18a 23. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001624c1b2 24. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000162f9c70 25. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x00000000162fa55a 26. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc6653 27. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000000fccc4c3 28. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc3d92 29. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fcca080 30. ? @ 0x00007fbc6213eac3 31. ? @ 0x00007fbc621d0850 (version 25.3.6.10636.altinitytest (altinity build)) 2025.07.28 12:02:02.862938 [ 17203 ] {} TCPHandler: TCPHandler: Code: 81. DB::Exception: Database test_11 does not exist. Maybe you meant test_1?. (UNKNOWN_DATABASE), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000a06a8eb 4. /build/src/Interpreters/DatabaseCatalog.cpp:535: DB::DatabaseCatalog::assertDatabaseExists(String const&) const @ 0x00000000144f31f6 5. /build/src/Server/TCPHandler.cpp:342: DB::TCPHandler::runImpl() @ 0x00000000168e5a19 6. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 7. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 8. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 9. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 10. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 11. ? @ 0x00007fbc6213eac3 12. ? @ 0x00007fbc621d0850 (version 25.3.6.10636.altinitytest (altinity build)) 2025.07.28 12:02:02.868787 [ 17203 ] {} ServerErrorHandler: Code: 81. DB::Exception: Database test_11 does not exist. Maybe you meant test_1?. (UNKNOWN_DATABASE), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000a06a8eb 4. /build/src/Interpreters/DatabaseCatalog.cpp:535: DB::DatabaseCatalog::assertDatabaseExists(String const&) const @ 0x00000000144f31f6 5. /build/src/Server/TCPHandler.cpp:342: DB::TCPHandler::runImpl() @ 0x00000000168e5a19 6. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 7. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 8. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 9. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 10. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 11. ? @ 0x00007fbc6213eac3 12. ? @ 0x00007fbc621d0850 (version 25.3.6.10636.altinitytest (altinity build)) 2025.07.28 12:02:03.600434 [ 3963 ] {} test_13.rmt2 (7f9b740d-015c-470e-8cc6-8ba33be0dc63): auto DB::StorageReplicatedMergeTree::processQueueEntry(ReplicatedMergeTreeQueue::SelectedEntryPtr)::(anonymous class)::operator()(LogEntryPtr &) const: Code: 86. DB::HTTPException: Received error from remote server http://146b4357c08d:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Ftest%2F01165%2Ftest_13%2Frmt%2Freplicas%2F1&part=20250728_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.6.10636.altinitytest (altinity build)) '. (RECEIVED_ERROR_FROM_REMOTE_IO_SERVER), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.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 const&, int&&, String const&, unsigned long&&, String const&) @ 0x000000000feda8d9 4. /build/src/IO/HTTPCommon.cpp:104: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x000000000feda6e2 5. /build/src/IO/HTTPCommon.cpp:93: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x000000000feda537 6. /build/src/IO/ReadWriteBufferFromHTTP.cpp:277: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x000000001184a4c4 7. /build/src/IO/ReadWriteBufferFromHTTP.cpp:285: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x000000001184a615 8. /build/src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x000000001184ae59 9. /build/src/IO/ReadWriteBufferFromHTTP.cpp:472: void std::__function::__policy_invoker::__call_impl[abi:se190107]>(std::__function::__policy_storage const*) @ 0x000000001184cedd 10. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001184858b 11. /build/src/IO/ReadWriteBufferFromHTTP.cpp:465: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x000000001184bf0b 12. /build/src/IO/ReadBuffer.h:60: DB::ReadBuffer::next() @ 0x000000000a148c7b 13. /build/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) @ 0x0000000011849fb2 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]>&)>&, 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&) @ 0x0000000011841980 15. /build/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) @ 0x000000001621208e 16. /build/src/Storages/StorageReplicatedMergeTree.cpp:5228: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl[abi:se190107] const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000015f9a5fe 17. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000015ed8bfd 18. /build/src/Storages/StorageReplicatedMergeTree.cpp:2514: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x0000000015ec9aab 19. /build/src/Storages/StorageReplicatedMergeTree.cpp:2349: DB::StorageReplicatedMergeTree::executeLogEntry(DB::ReplicatedMergeTreeLogEntry&) @ 0x0000000015eba91b 20. /build/src/Storages/StorageReplicatedMergeTree.cpp:3876: bool std::__function::__policy_invoker&)>::__call_impl[abi:se190107])::$_1, bool (std::shared_ptr&)>>(std::__function::__policy_storage const*, std::shared_ptr&) @ 0x0000000015f9837e 21. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000165d6fc3 22. /build/src/Storages/StorageReplicatedMergeTree.cpp:3872: DB::StorageReplicatedMergeTree::processQueueEntry(std::shared_ptr) @ 0x0000000015efc18a 23. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001624c1b2 24. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000162f9c70 25. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x00000000162fa55a 26. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc6653 27. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000000fccc4c3 28. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc3d92 29. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fcca080 30. ? @ 0x00007fbc6213eac3 31. ? @ 0x00007fbc621d0850 (version 25.3.6.10636.altinitytest (altinity build)) 2025.07.28 12:02:03.789213 [ 4963 ] {} 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. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception>&, String>(int, FormatStringHelperImpl>&>::type, std::type_identity::type>, std::basic_string_view>&, String&&) @ 0x000000001385a5eb 4. /build/src/Access/SettingsConstraints.cpp:376: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000013859b18 5. /build/src/Access/SettingsConstraints.cpp:300: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000013858faf 6. /build/src/Access/SettingsConstraints.cpp:209: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000013859223 7. /build/src/Interpreters/Context.cpp:2690: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000014436134 8. /build/src/Interpreters/Context.cpp:2729: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x000000001443662b 9. /build/src/Server/HTTPHandler.cpp:457: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000001686d165 10. /build/src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x0000000016870807 11. /build/src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x0000000016907e99 12. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 13. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 14. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 15. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 16. ? @ 0x00007fbc6213eac3 17. ? @ 0x00007fbc621d0850 (version 25.3.6.10636.altinitytest (altinity build)) 2025.07.28 12:02:03.892165 [ 5951 ] {5f9b6d6c-e8c9-4b98-be7e-9bb88b4af17f} executeQuery: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=50, jobs=1): While executing MergeTreeSelect(pool: ReadPool, algorithm: Thread). (CANNOT_SCHEDULE_TASK) (version 25.3.6.10636.altinitytest (altinity build)) (from [::1]:39350) (comment: 02226_low_cardinality_text_bloom_filter_index.sql) (query 20, line 40) (in query: SELECT * FROM bf_ngram_lowcard_test WHERE like(lc, 'K3') SETTINGS force_data_skipping_indices='lc_ngram';), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000fccaeeb 4. /build/src/Common/ThreadPool.cpp:275: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000fccc813 5. /build/src/Common/ThreadPool.cpp:323: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fcc7bbc 6. /build/src/Common/ThreadPool.cpp:494: ThreadPoolImpl>::scheduleOrThrowOnError(std::function, Priority) @ 0x000000000fcc7a0e 7. /build/src/Common/threadPoolCallbackRunner.h:52: std::future> std::__function::__policy_invoker> (DB::MergeTreeMarksLoader::loadMarksAsync()::$_0&&, Priority)>::__call_impl[abi:se190107]> (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&&) @ 0x0000000016474731 8. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000016471940 9. /build/src/Storages/MergeTree/MergeTreeMarksLoader.cpp:83: DB::MergeTreeMarksLoader::startAsyncLoad() @ 0x000000001647173f 10. /build/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) @ 0x000000001648df37 11. /build/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&&) @ 0x00000000163c608d 12. /build/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 @ 0x00000000163c27d4 13. /build/src/Storages/MergeTree/MergeTreeReadTask.cpp:60: DB::MergeTreeReadTask::createReaders(std::shared_ptr const&, DB::MergeTreeReadTask::Extras const&, DB::MarkRanges const&) @ 0x00000000164b540d 14. /build/src/Storages/MergeTree/MergeTreeReadPoolBase.cpp:274: DB::MergeTreeReadPoolBase::createTask(std::shared_ptr, DB::MarkRanges, DB::MergeTreeReadTask*) const @ 0x0000000016e53b1f 15. /build/src/Storages/MergeTree/MergeTreeReadPool.cpp:159: DB::MergeTreeReadPool::getTask(unsigned long, DB::MergeTreeReadTask*) @ 0x0000000016e71eca 16. /build/src/Storages/MergeTree/MergeTreeSelectProcessor.cpp:191: DB::MergeTreeSelectProcessor::read() @ 0x00000000164c0b40 17. /build/src/Storages/MergeTree/MergeTreeSource.cpp:229: DB::MergeTreeSource::tryGenerate() @ 0x0000000016e43d69 18. /build/src/Processors/ISource.cpp:108: DB::ISource::work() @ 0x00000000169a21e7 19. /build/src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x00000000169bd00f 20. /build/src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x00000000169b2105 21. /build/src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeSingleThread(unsigned long) @ 0x00000000169b23be 22. /build/src/Processors/Executors/PipelineExecutor.cpp:416: void std::__function::__policy_invoker::__call_impl[abi:se190107]>(std::__function::__policy_storage const*) @ 0x00000000169b2e3f 23. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc6653 24. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000000fccc4c3 25. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc3d92 26. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fcca080 27. ? @ 0x00007fbc6213eac3 28. ? @ 0x00007fbc621d0850 2025.07.28 12:02:03.905816 [ 5951 ] {} TCPHandler: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=50, jobs=1): While executing MergeTreeSelect(pool: ReadPool, algorithm: Thread). (CANNOT_SCHEDULE_TASK), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000fccaeeb 4. /build/src/Common/ThreadPool.cpp:275: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000fccc813 5. /build/src/Common/ThreadPool.cpp:323: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fcc7bbc 6. /build/src/Common/ThreadPool.cpp:494: ThreadPoolImpl>::scheduleOrThrowOnError(std::function, Priority) @ 0x000000000fcc7a0e 7. /build/src/Common/threadPoolCallbackRunner.h:52: std::future> std::__function::__policy_invoker> (DB::MergeTreeMarksLoader::loadMarksAsync()::$_0&&, Priority)>::__call_impl[abi:se190107]> (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&&) @ 0x0000000016474731 8. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000016471940 9. /build/src/Storages/MergeTree/MergeTreeMarksLoader.cpp:83: DB::MergeTreeMarksLoader::startAsyncLoad() @ 0x000000001647173f 10. /build/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) @ 0x000000001648df37 11. /build/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&&) @ 0x00000000163c608d 12. /build/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 @ 0x00000000163c27d4 13. /build/src/Storages/MergeTree/MergeTreeReadTask.cpp:60: DB::MergeTreeReadTask::createReaders(std::shared_ptr const&, DB::MergeTreeReadTask::Extras const&, DB::MarkRanges const&) @ 0x00000000164b540d 14. /build/src/Storages/MergeTree/MergeTreeReadPoolBase.cpp:274: DB::MergeTreeReadPoolBase::createTask(std::shared_ptr, DB::MarkRanges, DB::MergeTreeReadTask*) const @ 0x0000000016e53b1f 15. /build/src/Storages/MergeTree/MergeTreeReadPool.cpp:159: DB::MergeTreeReadPool::getTask(unsigned long, DB::MergeTreeReadTask*) @ 0x0000000016e71eca 16. /build/src/Storages/MergeTree/MergeTreeSelectProcessor.cpp:191: DB::MergeTreeSelectProcessor::read() @ 0x00000000164c0b40 17. /build/src/Storages/MergeTree/MergeTreeSource.cpp:229: DB::MergeTreeSource::tryGenerate() @ 0x0000000016e43d69 18. /build/src/Processors/ISource.cpp:108: DB::ISource::work() @ 0x00000000169a21e7 19. /build/src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x00000000169bd00f 20. /build/src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x00000000169b2105 21. /build/src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeSingleThread(unsigned long) @ 0x00000000169b23be 22. /build/src/Processors/Executors/PipelineExecutor.cpp:416: void std::__function::__policy_invoker::__call_impl[abi:se190107]>(std::__function::__policy_storage const*) @ 0x00000000169b2e3f 23. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc6653 24. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000000fccc4c3 25. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc3d92 26. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fcca080 27. ? @ 0x00007fbc6213eac3 28. ? @ 0x00007fbc621d0850 Job's origin stack trace: 0. /build/src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000000fc33b84 1. /build/src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000000fcc2ea7 2. /build/src/Common/ThreadPool.cpp:401: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fcc7f1c 3. /build/src/Common/ThreadPool.cpp:494: ThreadPoolImpl>::scheduleOrThrowOnError(std::function, Priority) @ 0x000000000fcc7a0e 4. /build/src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::spawnThreadsImpl() @ 0x00000000169b2c0c 5. /build/src/Processors/Executors/PipelineExecutor.cpp:394: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x00000000169b0ba7 6. /build/src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x00000000169b03f4 7. /build/src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:se190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169bfeab 8. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc3d92 9. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fcca080 10. ? @ 0x00007fbc6213eac3 11. ? @ 0x00007fbc621d0850 Job's origin stack trace: 0. /build/src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000000fc33b84 1. /build/src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000000fcc2ea7 2. /build/src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fcc535c 3. /build/src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000000fcc584d 4. /build/src/Common/ThreadPool.h:279: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x00000000169bf193 5. /build/src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x00000000169bf518 6. /build/src/Server/TCPHandler.cpp:1237: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x00000000168f1525 7. /build/src/Server/TCPHandler.cpp:678: DB::TCPHandler::runImpl() @ 0x00000000168e68e5 8. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 9. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 10. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 11. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 12. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 13. ? @ 0x00007fbc6213eac3 14. ? @ 0x00007fbc621d0850 2025.07.28 12:02:04.217170 [ 3972 ] {} test_13.rmt2 (7f9b740d-015c-470e-8cc6-8ba33be0dc63): auto DB::StorageReplicatedMergeTree::processQueueEntry(ReplicatedMergeTreeQueue::SelectedEntryPtr)::(anonymous class)::operator()(LogEntryPtr &) const: Code: 86. DB::HTTPException: Received error from remote server http://146b4357c08d:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Ftest%2F01165%2Ftest_13%2Frmt%2Freplicas%2F1&part=20250728_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.6.10636.altinitytest (altinity build)) '. (RECEIVED_ERROR_FROM_REMOTE_IO_SERVER), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.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 const&, int&&, String const&, unsigned long&&, String const&) @ 0x000000000feda8d9 4. /build/src/IO/HTTPCommon.cpp:104: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x000000000feda6e2 5. /build/src/IO/HTTPCommon.cpp:93: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x000000000feda537 6. /build/src/IO/ReadWriteBufferFromHTTP.cpp:277: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x000000001184a4c4 7. /build/src/IO/ReadWriteBufferFromHTTP.cpp:285: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x000000001184a615 8. /build/src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x000000001184ae59 9. /build/src/IO/ReadWriteBufferFromHTTP.cpp:472: void std::__function::__policy_invoker::__call_impl[abi:se190107]>(std::__function::__policy_storage const*) @ 0x000000001184cedd 10. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001184858b 11. /build/src/IO/ReadWriteBufferFromHTTP.cpp:465: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x000000001184bf0b 12. /build/src/IO/ReadBuffer.h:60: DB::ReadBuffer::next() @ 0x000000000a148c7b 13. /build/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) @ 0x0000000011849fb2 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]>&)>&, 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&) @ 0x0000000011841980 15. /build/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) @ 0x000000001621208e 16. /build/src/Storages/StorageReplicatedMergeTree.cpp:5228: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl[abi:se190107] const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000015f9a5fe 17. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000015ed8bfd 18. /build/src/Storages/StorageReplicatedMergeTree.cpp:2514: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x0000000015ec9aab 19. /build/src/Storages/StorageReplicatedMergeTree.cpp:2349: DB::StorageReplicatedMergeTree::executeLogEntry(DB::ReplicatedMergeTreeLogEntry&) @ 0x0000000015eba91b 20. /build/src/Storages/StorageReplicatedMergeTree.cpp:3876: bool std::__function::__policy_invoker&)>::__call_impl[abi:se190107])::$_1, bool (std::shared_ptr&)>>(std::__function::__policy_storage const*, std::shared_ptr&) @ 0x0000000015f9837e 21. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000165d6fc3 22. /build/src/Storages/StorageReplicatedMergeTree.cpp:3872: DB::StorageReplicatedMergeTree::processQueueEntry(std::shared_ptr) @ 0x0000000015efc18a 23. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001624c1b2 24. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000162f9c70 25. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x00000000162fa55a 26. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc6653 27. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000000fccc4c3 28. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc3d92 29. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fcca080 30. ? @ 0x00007fbc6213eac3 31. ? @ 0x00007fbc621d0850 (version 25.3.6.10636.altinitytest (altinity build)) 2025.07.28 12:02:04.474753 [ 3976 ] {} test_13.rmt2 (7f9b740d-015c-470e-8cc6-8ba33be0dc63): auto DB::StorageReplicatedMergeTree::processQueueEntry(ReplicatedMergeTreeQueue::SelectedEntryPtr)::(anonymous class)::operator()(LogEntryPtr &) const: Code: 86. DB::HTTPException: Received error from remote server http://146b4357c08d:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Ftest%2F01165%2Ftest_13%2Frmt%2Freplicas%2F1&part=20250728_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.6.10636.altinitytest (altinity build)) '. (RECEIVED_ERROR_FROM_REMOTE_IO_SERVER), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.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 const&, int&&, String const&, unsigned long&&, String const&) @ 0x000000000feda8d9 4. /build/src/IO/HTTPCommon.cpp:104: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x000000000feda6e2 5. /build/src/IO/HTTPCommon.cpp:93: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x000000000feda537 6. /build/src/IO/ReadWriteBufferFromHTTP.cpp:277: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x000000001184a4c4 7. /build/src/IO/ReadWriteBufferFromHTTP.cpp:285: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x000000001184a615 8. /build/src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x000000001184ae59 9. /build/src/IO/ReadWriteBufferFromHTTP.cpp:472: void std::__function::__policy_invoker::__call_impl[abi:se190107]>(std::__function::__policy_storage const*) @ 0x000000001184cedd 10. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001184858b 11. /build/src/IO/ReadWriteBufferFromHTTP.cpp:465: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x000000001184bf0b 12. /build/src/IO/ReadBuffer.h:60: DB::ReadBuffer::next() @ 0x000000000a148c7b 13. /build/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) @ 0x0000000011849fb2 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]>&)>&, 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&) @ 0x0000000011841980 15. /build/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) @ 0x000000001621208e 16. /build/src/Storages/StorageReplicatedMergeTree.cpp:5228: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl[abi:se190107] const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000015f9a5fe 17. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000015ed8bfd 18. /build/src/Storages/StorageReplicatedMergeTree.cpp:2514: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x0000000015ec9aab 19. /build/src/Storages/StorageReplicatedMergeTree.cpp:2349: DB::StorageReplicatedMergeTree::executeLogEntry(DB::ReplicatedMergeTreeLogEntry&) @ 0x0000000015eba91b 20. /build/src/Storages/StorageReplicatedMergeTree.cpp:3876: bool std::__function::__policy_invoker&)>::__call_impl[abi:se190107])::$_1, bool (std::shared_ptr&)>>(std::__function::__policy_storage const*, std::shared_ptr&) @ 0x0000000015f9837e 21. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000165d6fc3 22. /build/src/Storages/StorageReplicatedMergeTree.cpp:3872: DB::StorageReplicatedMergeTree::processQueueEntry(std::shared_ptr) @ 0x0000000015efc18a 23. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001624c1b2 24. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000162f9c70 25. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x00000000162fa55a 26. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc6653 27. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000000fccc4c3 28. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc3d92 29. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fcca080 30. ? @ 0x00007fbc6213eac3 31. ? @ 0x00007fbc621d0850 (version 25.3.6.10636.altinitytest (altinity build)) 2025.07.28 12:02:05.551733 [ 3960 ] {} test_13.rmt2 (7f9b740d-015c-470e-8cc6-8ba33be0dc63): auto DB::StorageReplicatedMergeTree::processQueueEntry(ReplicatedMergeTreeQueue::SelectedEntryPtr)::(anonymous class)::operator()(LogEntryPtr &) const: Code: 86. DB::HTTPException: Received error from remote server http://146b4357c08d:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Ftest%2F01165%2Ftest_13%2Frmt%2Freplicas%2F1&part=20250728_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.6.10636.altinitytest (altinity build)) '. (RECEIVED_ERROR_FROM_REMOTE_IO_SERVER), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.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 const&, int&&, String const&, unsigned long&&, String const&) @ 0x000000000feda8d9 4. /build/src/IO/HTTPCommon.cpp:104: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x000000000feda6e2 5. /build/src/IO/HTTPCommon.cpp:93: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x000000000feda537 6. /build/src/IO/ReadWriteBufferFromHTTP.cpp:277: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x000000001184a4c4 7. /build/src/IO/ReadWriteBufferFromHTTP.cpp:285: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x000000001184a615 8. /build/src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x000000001184ae59 9. /build/src/IO/ReadWriteBufferFromHTTP.cpp:472: void std::__function::__policy_invoker::__call_impl[abi:se190107]>(std::__function::__policy_storage const*) @ 0x000000001184cedd 10. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001184858b 11. /build/src/IO/ReadWriteBufferFromHTTP.cpp:465: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x000000001184bf0b 12. /build/src/IO/ReadBuffer.h:60: DB::ReadBuffer::next() @ 0x000000000a148c7b 13. /build/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) @ 0x0000000011849fb2 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]>&)>&, 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&) @ 0x0000000011841980 15. /build/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) @ 0x000000001621208e 16. /build/src/Storages/StorageReplicatedMergeTree.cpp:5228: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl[abi:se190107] const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000015f9a5fe 17. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000015ed8bfd 18. /build/src/Storages/StorageReplicatedMergeTree.cpp:2514: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x0000000015ec9aab 19. /build/src/Storages/StorageReplicatedMergeTree.cpp:2349: DB::StorageReplicatedMergeTree::executeLogEntry(DB::ReplicatedMergeTreeLogEntry&) @ 0x0000000015eba91b 20. /build/src/Storages/StorageReplicatedMergeTree.cpp:3876: bool std::__function::__policy_invoker&)>::__call_impl[abi:se190107])::$_1, bool (std::shared_ptr&)>>(std::__function::__policy_storage const*, std::shared_ptr&) @ 0x0000000015f9837e 21. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000165d6fc3 22. /build/src/Storages/StorageReplicatedMergeTree.cpp:3872: DB::StorageReplicatedMergeTree::processQueueEntry(std::shared_ptr) @ 0x0000000015efc18a 23. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001624c1b2 24. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000162f9c70 25. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x00000000162fa55a 26. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc6653 27. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000000fccc4c3 28. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc3d92 29. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fcca080 30. ? @ 0x00007fbc6213eac3 31. ? @ 0x00007fbc621d0850 (version 25.3.6.10636.altinitytest (altinity build)) 2025.07.28 12:02:05.760065 [ 3967 ] {} test_13.rmt2 (7f9b740d-015c-470e-8cc6-8ba33be0dc63): auto DB::StorageReplicatedMergeTree::processQueueEntry(ReplicatedMergeTreeQueue::SelectedEntryPtr)::(anonymous class)::operator()(LogEntryPtr &) const: Code: 86. DB::HTTPException: Received error from remote server http://146b4357c08d:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Ftest%2F01165%2Ftest_13%2Frmt%2Freplicas%2F1&part=20250728_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.6.10636.altinitytest (altinity build)) '. (RECEIVED_ERROR_FROM_REMOTE_IO_SERVER), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.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 const&, int&&, String const&, unsigned long&&, String const&) @ 0x000000000feda8d9 4. /build/src/IO/HTTPCommon.cpp:104: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x000000000feda6e2 5. /build/src/IO/HTTPCommon.cpp:93: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x000000000feda537 6. /build/src/IO/ReadWriteBufferFromHTTP.cpp:277: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x000000001184a4c4 7. /build/src/IO/ReadWriteBufferFromHTTP.cpp:285: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x000000001184a615 8. /build/src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x000000001184ae59 9. /build/src/IO/ReadWriteBufferFromHTTP.cpp:472: void std::__function::__policy_invoker::__call_impl[abi:se190107]>(std::__function::__policy_storage const*) @ 0x000000001184cedd 10. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001184858b 11. /build/src/IO/ReadWriteBufferFromHTTP.cpp:465: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x000000001184bf0b 12. /build/src/IO/ReadBuffer.h:60: DB::ReadBuffer::next() @ 0x000000000a148c7b 13. /build/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) @ 0x0000000011849fb2 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]>&)>&, 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&) @ 0x0000000011841980 15. /build/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) @ 0x000000001621208e 16. /build/src/Storages/StorageReplicatedMergeTree.cpp:5228: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl[abi:se190107] const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000015f9a5fe 17. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000015ed8bfd 18. /build/src/Storages/StorageReplicatedMergeTree.cpp:2514: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x0000000015ec9aab 19. /build/src/Storages/StorageReplicatedMergeTree.cpp:2349: DB::StorageReplicatedMergeTree::executeLogEntry(DB::ReplicatedMergeTreeLogEntry&) @ 0x0000000015eba91b 20. /build/src/Storages/StorageReplicatedMergeTree.cpp:3876: bool std::__function::__policy_invoker&)>::__call_impl[abi:se190107])::$_1, bool (std::shared_ptr&)>>(std::__function::__policy_storage const*, std::shared_ptr&) @ 0x0000000015f9837e 21. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000165d6fc3 22. /build/src/Storages/StorageReplicatedMergeTree.cpp:3872: DB::StorageReplicatedMergeTree::processQueueEntry(std::shared_ptr) @ 0x0000000015efc18a 23. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001624c1b2 24. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000162f9c70 25. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x00000000162fa55a 26. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc6653 27. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000000fccc4c3 28. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc3d92 29. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fcca080 30. ? @ 0x00007fbc6213eac3 31. ? @ 0x00007fbc621d0850 (version 25.3.6.10636.altinitytest (altinity build)) 2025.07.28 12:02:05.989349 [ 5951 ] {5433fc8d-d8d3-474a-ab22-0b99b5c48138} executeQuery: Code: 57. DB::Exception: Table test_jjovt79a.test_replicated already exists. (TABLE_ALREADY_EXISTS) (version 25.3.6.10636.altinitytest (altinity build)) (from [::1]:42202) (comment: 02676_optimize_old_parts_replicated.sh) (query 3, line 6) (in query: CREATE TABLE test_replicated (`i` Int64) ENGINE = ReplicatedMergeTree('/clickhouse/tables/{database}/test02676_partition_only', 'node') PARTITION BY i ORDER BY i SETTINGS min_age_to_force_merge_seconds = 1, merge_selecting_sleep_ms = 1000, min_age_to_force_merge_on_partition_only = true, index_granularity = 22934, min_bytes_for_wide_part = 736178486, ratio_of_defaults_for_sparse_serialization = 0., replace_long_file_name_to_hash = false, max_file_name_length = 92, min_bytes_for_full_part_storage = 0, compact_parts_max_bytes_to_buffer = 251706375, compact_parts_max_granules_to_buffer = 176, compact_parts_merge_max_bytes_to_prefetch_part = 21819644, merge_max_block_size = 7486, old_parts_lifetime = 480., prefer_fetch_merged_part_size_threshold = 6152329222, vertical_merge_algorithm_min_rows_to_activate = 169403, vertical_merge_algorithm_min_columns_to_activate = 1, min_merge_bytes_to_use_direct_io = 10737418240, index_granularity_bytes = 23801364, 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 = true, cache_populated_by_fetch = true, marks_compress_block_size = 61265, primary_key_compress_block_size = 40308, 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. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000a06a8eb 4. /build/src/Interpreters/InterpreterCreateQuery.cpp:1824: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x0000000014901d53 5. /build/src/Interpreters/InterpreterCreateQuery.cpp:1743: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000148f9aa9 6. /build/src/Interpreters/InterpreterCreateQuery.cpp:2352: DB::InterpreterCreateQuery::execute() @ 0x0000000014905a41 7. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88dc9 8. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 9. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 10. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 11. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 12. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 13. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 14. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 15. ? @ 0x00007fbc6213eac3 16. ? @ 0x00007fbc621d0850 2025.07.28 12:02:05.992748 [ 5951 ] {} TCPHandler: Code: 57. DB::Exception: Table test_jjovt79a.test_replicated already exists. (TABLE_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000a06a8eb 4. /build/src/Interpreters/InterpreterCreateQuery.cpp:1824: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x0000000014901d53 5. /build/src/Interpreters/InterpreterCreateQuery.cpp:1743: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000148f9aa9 6. /build/src/Interpreters/InterpreterCreateQuery.cpp:2352: DB::InterpreterCreateQuery::execute() @ 0x0000000014905a41 7. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88dc9 8. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 9. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 10. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 11. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 12. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 13. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 14. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 15. ? @ 0x00007fbc6213eac3 16. ? @ 0x00007fbc621d0850 2025.07.28 12:02:06.532331 [ 5879 ] {50ea8298-3b4a-4f2e-a81f-37244de639ac} executeQuery: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=881, jobs=845). (CANNOT_SCHEDULE_TASK) (version 25.3.6.10636.altinitytest (altinity build)) (from [::1]:42218) (comment: 00974_final_predicate_push_down.sql) (query 6, line 15) (in query: SELECT COUNT() FROM (SELECT * FROM test_00974 FINAL) where x = 1 SETTINGS enable_optimize_predicate_expression_to_final_subquery = 0;), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000fccaeeb 4. /build/src/Common/ThreadPool.cpp:275: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000fccacb3 5. /build/src/Common/ThreadPool.cpp:323: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fcc4ffc 6. /build/src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000000fcc584d 7. /build/src/Common/ThreadPool.h:279: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x00000000169bf193 8. /build/src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x00000000169bf518 9. /build/src/Server/TCPHandler.cpp:1237: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x00000000168f1525 10. /build/src/Server/TCPHandler.cpp:678: DB::TCPHandler::runImpl() @ 0x00000000168e68e5 11. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 12. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 13. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 14. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 15. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 16. ? @ 0x00007fbc6213eac3 17. ? @ 0x00007fbc621d0850 2025.07.28 12:02:06.546607 [ 5879 ] {} TCPHandler: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=881, jobs=845). (CANNOT_SCHEDULE_TASK), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000fccaeeb 4. /build/src/Common/ThreadPool.cpp:275: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000fccacb3 5. /build/src/Common/ThreadPool.cpp:323: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fcc4ffc 6. /build/src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000000fcc584d 7. /build/src/Common/ThreadPool.h:279: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x00000000169bf193 8. /build/src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x00000000169bf518 9. /build/src/Server/TCPHandler.cpp:1237: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x00000000168f1525 10. /build/src/Server/TCPHandler.cpp:678: DB::TCPHandler::runImpl() @ 0x00000000168e68e5 11. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 12. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 13. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 14. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 15. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 16. ? @ 0x00007fbc6213eac3 17. ? @ 0x00007fbc621d0850 2025.07.28 12:02:06.591467 [ 3964 ] {} test_13.rmt2 (7f9b740d-015c-470e-8cc6-8ba33be0dc63): auto DB::StorageReplicatedMergeTree::processQueueEntry(ReplicatedMergeTreeQueue::SelectedEntryPtr)::(anonymous class)::operator()(LogEntryPtr &) const: Code: 86. DB::HTTPException: Received error from remote server http://146b4357c08d:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Ftest%2F01165%2Ftest_13%2Frmt%2Freplicas%2F1&part=20250728_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.6.10636.altinitytest (altinity build)) '. (RECEIVED_ERROR_FROM_REMOTE_IO_SERVER), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.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 const&, int&&, String const&, unsigned long&&, String const&) @ 0x000000000feda8d9 4. /build/src/IO/HTTPCommon.cpp:104: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x000000000feda6e2 5. /build/src/IO/HTTPCommon.cpp:93: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x000000000feda537 6. /build/src/IO/ReadWriteBufferFromHTTP.cpp:277: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x000000001184a4c4 7. /build/src/IO/ReadWriteBufferFromHTTP.cpp:285: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x000000001184a615 8. /build/src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x000000001184ae59 9. /build/src/IO/ReadWriteBufferFromHTTP.cpp:472: void std::__function::__policy_invoker::__call_impl[abi:se190107]>(std::__function::__policy_storage const*) @ 0x000000001184cedd 10. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001184858b 11. /build/src/IO/ReadWriteBufferFromHTTP.cpp:465: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x000000001184bf0b 12. /build/src/IO/ReadBuffer.h:60: DB::ReadBuffer::next() @ 0x000000000a148c7b 13. /build/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) @ 0x0000000011849fb2 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]>&)>&, 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&) @ 0x0000000011841980 15. /build/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) @ 0x000000001621208e 16. /build/src/Storages/StorageReplicatedMergeTree.cpp:5228: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl[abi:se190107] const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000015f9a5fe 17. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000015ed8bfd 18. /build/src/Storages/StorageReplicatedMergeTree.cpp:2514: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x0000000015ec9aab 19. /build/src/Storages/StorageReplicatedMergeTree.cpp:2349: DB::StorageReplicatedMergeTree::executeLogEntry(DB::ReplicatedMergeTreeLogEntry&) @ 0x0000000015eba91b 20. /build/src/Storages/StorageReplicatedMergeTree.cpp:3876: bool std::__function::__policy_invoker&)>::__call_impl[abi:se190107])::$_1, bool (std::shared_ptr&)>>(std::__function::__policy_storage const*, std::shared_ptr&) @ 0x0000000015f9837e 21. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000165d6fc3 22. /build/src/Storages/StorageReplicatedMergeTree.cpp:3872: DB::StorageReplicatedMergeTree::processQueueEntry(std::shared_ptr) @ 0x0000000015efc18a 23. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001624c1b2 24. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000162f9c70 25. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x00000000162fa55a 26. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc6653 27. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000000fccc4c3 28. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc3d92 29. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fcca080 30. ? @ 0x00007fbc6213eac3 31. ? @ 0x00007fbc621d0850 (version 25.3.6.10636.altinitytest (altinity build)) 2025.07.28 12:02:06.625891 [ 4963 ] {3d757246-567a-4e79-ad79-a4185a3be91d} executeQuery: Code: 219. DB::Exception: New table appeared in database being dropped or detached. Try again. (DATABASE_NOT_EMPTY) (version 25.3.6.10636.altinitytest (altinity build)) (from [::1]:35250) (comment: 00974_final_predicate_push_down.sql) (in query: DROP DATABASE IF EXISTS test_fhu4920d SYNC ), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000000a074fcb 4. /build/src/Interpreters/DatabaseCatalog.cpp:608: DB::DatabaseCatalog::detachDatabase(std::shared_ptr, String const&, bool, bool) @ 0x00000000144f41b9 5. /build/src/Interpreters/InterpreterDropQuery.cpp:482: DB::InterpreterDropQuery::executeToDatabaseImpl(DB::ASTDropQuery const&, std::shared_ptr&, std::vector, DB::UUIDTag>, std::allocator, DB::UUIDTag>>>&) @ 0x00000000149179be 6. /build/src/Interpreters/InterpreterDropQuery.cpp:363: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x0000000014913988 7. /build/src/Interpreters/InterpreterDropQuery.cpp:99: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000014913142 8. /build/src/Interpreters/InterpreterDropQuery.cpp:72: DB::InterpreterDropQuery::execute() @ 0x0000000014912b65 9. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88dc9 10. /build/src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x0000000014c8ca7b 11. /build/src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000001686da12 12. /build/src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x0000000016870807 13. /build/src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x0000000016907e99 14. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 15. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 16. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 17. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 18. ? @ 0x00007fbc6213eac3 19. ? @ 0x00007fbc621d0850 2025.07.28 12:02:06.628597 [ 4963 ] {3d757246-567a-4e79-ad79-a4185a3be91d} 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. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000000a074fcb 4. /build/src/Interpreters/DatabaseCatalog.cpp:608: DB::DatabaseCatalog::detachDatabase(std::shared_ptr, String const&, bool, bool) @ 0x00000000144f41b9 5. /build/src/Interpreters/InterpreterDropQuery.cpp:482: DB::InterpreterDropQuery::executeToDatabaseImpl(DB::ASTDropQuery const&, std::shared_ptr&, std::vector, DB::UUIDTag>, std::allocator, DB::UUIDTag>>>&) @ 0x00000000149179be 6. /build/src/Interpreters/InterpreterDropQuery.cpp:363: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x0000000014913988 7. /build/src/Interpreters/InterpreterDropQuery.cpp:99: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000014913142 8. /build/src/Interpreters/InterpreterDropQuery.cpp:72: DB::InterpreterDropQuery::execute() @ 0x0000000014912b65 9. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88dc9 10. /build/src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x0000000014c8ca7b 11. /build/src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000001686da12 12. /build/src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x0000000016870807 13. /build/src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x0000000016907e99 14. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 15. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 16. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 17. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 18. ? @ 0x00007fbc6213eac3 19. ? @ 0x00007fbc621d0850 (version 25.3.6.10636.altinitytest (altinity build)) 2025.07.28 12:02:07.621174 [ 3968 ] {} test_13.rmt2 (7f9b740d-015c-470e-8cc6-8ba33be0dc63): auto DB::StorageReplicatedMergeTree::processQueueEntry(ReplicatedMergeTreeQueue::SelectedEntryPtr)::(anonymous class)::operator()(LogEntryPtr &) const: Code: 86. DB::HTTPException: Received error from remote server http://146b4357c08d:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Ftest%2F01165%2Ftest_13%2Frmt%2Freplicas%2F1&part=20250728_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.6.10636.altinitytest (altinity build)) '. (RECEIVED_ERROR_FROM_REMOTE_IO_SERVER), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.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 const&, int&&, String const&, unsigned long&&, String const&) @ 0x000000000feda8d9 4. /build/src/IO/HTTPCommon.cpp:104: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x000000000feda6e2 5. /build/src/IO/HTTPCommon.cpp:93: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x000000000feda537 6. /build/src/IO/ReadWriteBufferFromHTTP.cpp:277: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x000000001184a4c4 7. /build/src/IO/ReadWriteBufferFromHTTP.cpp:285: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x000000001184a615 8. /build/src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x000000001184ae59 9. /build/src/IO/ReadWriteBufferFromHTTP.cpp:472: void std::__function::__policy_invoker::__call_impl[abi:se190107]>(std::__function::__policy_storage const*) @ 0x000000001184cedd 10. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001184858b 11. /build/src/IO/ReadWriteBufferFromHTTP.cpp:465: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x000000001184bf0b 12. /build/src/IO/ReadBuffer.h:60: DB::ReadBuffer::next() @ 0x000000000a148c7b 13. /build/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) @ 0x0000000011849fb2 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]>&)>&, 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&) @ 0x0000000011841980 15. /build/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) @ 0x000000001621208e 16. /build/src/Storages/StorageReplicatedMergeTree.cpp:5228: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl[abi:se190107] const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000015f9a5fe 17. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000015ed8bfd 18. /build/src/Storages/StorageReplicatedMergeTree.cpp:2514: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x0000000015ec9aab 19. /build/src/Storages/StorageReplicatedMergeTree.cpp:2349: DB::StorageReplicatedMergeTree::executeLogEntry(DB::ReplicatedMergeTreeLogEntry&) @ 0x0000000015eba91b 20. /build/src/Storages/StorageReplicatedMergeTree.cpp:3876: bool std::__function::__policy_invoker&)>::__call_impl[abi:se190107])::$_1, bool (std::shared_ptr&)>>(std::__function::__policy_storage const*, std::shared_ptr&) @ 0x0000000015f9837e 21. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000165d6fc3 22. /build/src/Storages/StorageReplicatedMergeTree.cpp:3872: DB::StorageReplicatedMergeTree::processQueueEntry(std::shared_ptr) @ 0x0000000015efc18a 23. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001624c1b2 24. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000162f9c70 25. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x00000000162fa55a 26. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc6653 27. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000000fccc4c3 28. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc3d92 29. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fcca080 30. ? @ 0x00007fbc6213eac3 31. ? @ 0x00007fbc621d0850 (version 25.3.6.10636.altinitytest (altinity build)) 2025.07.28 12:02:07.765147 [ 17256 ] {} TCPHandler: Code: 394. DB::Exception: Query '5f6d2352-b5f8-4205-a5b1-000270859b49' is killed in pending state. (QUERY_WAS_CANCELLED), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x000000000a06b56b 4. /build/src/Interpreters/executeQuery.cpp:1522: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c8a4ef 5. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 6. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 7. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 8. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 9. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 10. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 11. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 12. ? @ 0x00007fbc6213eac3 13. ? @ 0x00007fbc621d0850 2025.07.28 12:02:07.786266 [ 17243 ] {} TCPHandler: Code: 394. DB::Exception: Query was cancelled. (QUERY_WAS_CANCELLED), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000000a074fcb 4. /build/src/Interpreters/ProcessList.cpp:567: DB::QueryStatus::throwQueryWasCancelled() const @ 0x0000000014a4bc85 5. /build/src/Interpreters/ProcessList.cpp:520: DB::QueryStatus::throwProperExceptionIfNeeded(unsigned long const&, unsigned long const&) @ 0x0000000014a4bbd9 6. /build/src/Interpreters/ProcessList.cpp:557: DB::QueryStatus::checkTimeLimit() @ 0x0000000014a4c2cd 7. /build/src/Processors/Executors/PipelineExecutor.cpp:206: DB::PipelineExecutor::finalizeExecution() @ 0x00000000169b13ba 8. /build/src/Processors/Executors/PipelineExecutor.cpp:181: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x00000000169b1726 9. /build/src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x00000000169c081c 10. /build/src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x00000000169c0978 11. /build/src/Interpreters/InterpreterKillQueryQuery.cpp:439: DB::InterpreterKillQueryQuery::getSelectResult(String const&, String const&) @ 0x0000000014cf0f04 12. /build/src/Interpreters/InterpreterKillQueryQuery.cpp:222: DB::InterpreterKillQueryQuery::execute() @ 0x0000000014cebde2 13. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88dc9 14. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 15. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 16. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 17. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 18. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 19. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 20. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 21. ? @ 0x00007fbc6213eac3 22. ? @ 0x00007fbc621d0850 2025.07.28 12:02:07.894918 [ 5879 ] {851d5f7c-67cb-4fc8-a94a-cbc5719fa904} executeQuery: Code: 394. DB::Exception: Query was cancelled. (QUERY_WAS_CANCELLED) (version 25.3.6.10636.altinitytest (altinity build)) (from [::1]:42266) (comment: 02461_cancel_finish_race.sh) (query 1, line 1) (in query: KILL QUERY WHERE current_database = 'test_dtwle8fg' SYNC FORMAT Null), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000000a074fcb 4. /build/src/Interpreters/ProcessList.cpp:567: DB::QueryStatus::throwQueryWasCancelled() const @ 0x0000000014a4bc85 5. /build/src/Interpreters/ProcessList.cpp:520: DB::QueryStatus::throwProperExceptionIfNeeded(unsigned long const&, unsigned long const&) @ 0x0000000014a4bbd9 6. /build/src/Interpreters/ProcessList.cpp:557: DB::QueryStatus::checkTimeLimit() @ 0x0000000014a4c2cd 7. /build/src/Processors/Executors/PipelineExecutor.cpp:206: DB::PipelineExecutor::finalizeExecution() @ 0x00000000169b13ba 8. /build/src/Processors/Executors/PipelineExecutor.cpp:153: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x00000000169b0584 9. /build/src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:se190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169bfeab 10. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc3d92 11. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fcca080 12. ? @ 0x00007fbc6213eac3 13. ? @ 0x00007fbc621d0850 2025.07.28 12:02:07.956002 [ 11826 ] {09feab15-1079-4436-b49e-eb6435f08216} executeQuery: Code: 394. DB::Exception: Query was cancelled. (QUERY_WAS_CANCELLED) (version 25.3.6.10636.altinitytest (altinity build)) (from [::1]:42324) (comment: 02461_cancel_finish_race.sh) (query 1, line 1) (in query: KILL QUERY WHERE current_database = 'test_dtwle8fg' SYNC FORMAT Null), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000000a074fcb 4. /build/src/Interpreters/ProcessList.cpp:567: DB::QueryStatus::throwQueryWasCancelled() const @ 0x0000000014a4bc85 5. /build/src/Interpreters/ProcessList.cpp:520: DB::QueryStatus::throwProperExceptionIfNeeded(unsigned long const&, unsigned long const&) @ 0x0000000014a4bbd9 6. /build/src/Interpreters/ProcessList.cpp:557: DB::QueryStatus::checkTimeLimit() @ 0x0000000014a4c2cd 7. /build/src/Processors/Executors/PipelineExecutor.cpp:206: DB::PipelineExecutor::finalizeExecution() @ 0x00000000169b13ba 8. /build/src/Processors/Executors/PipelineExecutor.cpp:153: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x00000000169b0584 9. /build/src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:se190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169bfeab 10. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc3d92 11. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fcca080 12. ? @ 0x00007fbc6213eac3 13. ? @ 0x00007fbc621d0850 2025.07.28 12:02:07.973590 [ 11826 ] {} TCPHandler: Code: 394. DB::Exception: Query was cancelled. (QUERY_WAS_CANCELLED), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000000a074fcb 4. /build/src/Interpreters/ProcessList.cpp:567: DB::QueryStatus::throwQueryWasCancelled() const @ 0x0000000014a4bc85 5. /build/src/Interpreters/ProcessList.cpp:520: DB::QueryStatus::throwProperExceptionIfNeeded(unsigned long const&, unsigned long const&) @ 0x0000000014a4bbd9 6. /build/src/Interpreters/ProcessList.cpp:557: DB::QueryStatus::checkTimeLimit() @ 0x0000000014a4c2cd 7. /build/src/Processors/Executors/PipelineExecutor.cpp:206: DB::PipelineExecutor::finalizeExecution() @ 0x00000000169b13ba 8. /build/src/Processors/Executors/PipelineExecutor.cpp:153: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x00000000169b0584 9. /build/src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:se190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169bfeab 10. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc3d92 11. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fcca080 12. ? @ 0x00007fbc6213eac3 13. ? @ 0x00007fbc621d0850 Job's origin stack trace: 0. /build/src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000000fc33b84 1. /build/src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000000fcc2ea7 2. /build/src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fcc535c 3. /build/src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000000fcc584d 4. /build/src/Common/ThreadPool.h:279: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x00000000169bf193 5. /build/src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x00000000169bf518 6. /build/src/Server/TCPHandler.cpp:1237: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x00000000168f1525 7. /build/src/Server/TCPHandler.cpp:678: DB::TCPHandler::runImpl() @ 0x00000000168e68e5 8. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 9. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 10. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 11. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 12. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 13. ? @ 0x00007fbc6213eac3 14. ? @ 0x00007fbc621d0850 2025.07.28 12:02:07.973950 [ 17255 ] {} TCPHandler: Code: 394. DB::Exception: Query was cancelled. (QUERY_WAS_CANCELLED), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000000a074fcb 4. /build/src/Interpreters/ProcessList.cpp:567: DB::QueryStatus::throwQueryWasCancelled() const @ 0x0000000014a4bc85 5. /build/src/Interpreters/ProcessList.cpp:520: DB::QueryStatus::throwProperExceptionIfNeeded(unsigned long const&, unsigned long const&) @ 0x0000000014a4bbd9 6. /build/src/Interpreters/ProcessList.cpp:557: DB::QueryStatus::checkTimeLimit() @ 0x0000000014a4c2cd 7. /build/src/Processors/Executors/PipelineExecutor.cpp:206: DB::PipelineExecutor::finalizeExecution() @ 0x00000000169b13ba 8. /build/src/Processors/Executors/PipelineExecutor.cpp:181: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x00000000169b1726 9. /build/src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x00000000169c081c 10. /build/src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x00000000169c0978 11. /build/src/Interpreters/InterpreterKillQueryQuery.cpp:439: DB::InterpreterKillQueryQuery::getSelectResult(String const&, String const&) @ 0x0000000014cf0f04 12. /build/src/Interpreters/InterpreterKillQueryQuery.cpp:222: DB::InterpreterKillQueryQuery::execute() @ 0x0000000014cebde2 13. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88dc9 14. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 15. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 16. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 17. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 18. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 19. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 20. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 21. ? @ 0x00007fbc6213eac3 22. ? @ 0x00007fbc621d0850 2025.07.28 12:02:07.976824 [ 5879 ] {} TCPHandler: Code: 394. DB::Exception: Query was cancelled. (QUERY_WAS_CANCELLED), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000000a074fcb 4. /build/src/Interpreters/ProcessList.cpp:567: DB::QueryStatus::throwQueryWasCancelled() const @ 0x0000000014a4bc85 5. /build/src/Interpreters/ProcessList.cpp:520: DB::QueryStatus::throwProperExceptionIfNeeded(unsigned long const&, unsigned long const&) @ 0x0000000014a4bbd9 6. /build/src/Interpreters/ProcessList.cpp:557: DB::QueryStatus::checkTimeLimit() @ 0x0000000014a4c2cd 7. /build/src/Processors/Executors/PipelineExecutor.cpp:206: DB::PipelineExecutor::finalizeExecution() @ 0x00000000169b13ba 8. /build/src/Processors/Executors/PipelineExecutor.cpp:153: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x00000000169b0584 9. /build/src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:se190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169bfeab 10. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc3d92 11. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fcca080 12. ? @ 0x00007fbc6213eac3 13. ? @ 0x00007fbc621d0850 Job's origin stack trace: 0. /build/src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000000fc33b84 1. /build/src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000000fcc2ea7 2. /build/src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fcc535c 3. /build/src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000000fcc584d 4. /build/src/Common/ThreadPool.h:279: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x00000000169bf193 5. /build/src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x00000000169bf518 6. /build/src/Server/TCPHandler.cpp:1237: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x00000000168f1525 7. /build/src/Server/TCPHandler.cpp:678: DB::TCPHandler::runImpl() @ 0x00000000168e68e5 8. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 9. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 10. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 11. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 12. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 13. ? @ 0x00007fbc6213eac3 14. ? @ 0x00007fbc621d0850 2025.07.28 12:02:07.984804 [ 7625 ] {} TCPHandler: Code: 394. DB::Exception: Query 'fd89b669-ab74-4416-bf97-8914f9e80e92' is killed in pending state. (QUERY_WAS_CANCELLED), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x000000000a06b56b 4. /build/src/Interpreters/executeQuery.cpp:1522: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c8a4ef 5. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 6. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 7. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 8. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 9. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 10. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 11. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 12. ? @ 0x00007fbc6213eac3 13. ? @ 0x00007fbc621d0850 2025.07.28 12:02:07.994140 [ 4963 ] {fc509472-2d9c-4e1a-aa21-7dbb31462d0a} executeQuery: Code: 394. DB::Exception: Query was cancelled. (QUERY_WAS_CANCELLED) (version 25.3.6.10636.altinitytest (altinity build)) (from [::1]:42334) (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. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000000a074fcb 4. /build/src/Interpreters/ProcessList.cpp:567: DB::QueryStatus::throwQueryWasCancelled() const @ 0x0000000014a4bc85 5. /build/src/Interpreters/ProcessList.cpp:520: DB::QueryStatus::throwProperExceptionIfNeeded(unsigned long const&, unsigned long const&) @ 0x0000000014a4bbd9 6. /build/src/Interpreters/ProcessList.cpp:557: DB::QueryStatus::checkTimeLimit() @ 0x0000000014a4c2cd 7. /build/src/Processors/Executors/PipelineExecutor.cpp:206: DB::PipelineExecutor::finalizeExecution() @ 0x00000000169b13ba 8. /build/src/Processors/Executors/PipelineExecutor.cpp:153: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x00000000169b0584 9. /build/src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:se190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169bfeab 10. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc3d92 11. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fcca080 12. ? @ 0x00007fbc6213eac3 13. ? @ 0x00007fbc621d0850 2025.07.28 12:02:08.004525 [ 4963 ] {} TCPHandler: Code: 394. DB::Exception: Query was cancelled. (QUERY_WAS_CANCELLED), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000000a074fcb 4. /build/src/Interpreters/ProcessList.cpp:567: DB::QueryStatus::throwQueryWasCancelled() const @ 0x0000000014a4bc85 5. /build/src/Interpreters/ProcessList.cpp:520: DB::QueryStatus::throwProperExceptionIfNeeded(unsigned long const&, unsigned long const&) @ 0x0000000014a4bbd9 6. /build/src/Interpreters/ProcessList.cpp:557: DB::QueryStatus::checkTimeLimit() @ 0x0000000014a4c2cd 7. /build/src/Processors/Executors/PipelineExecutor.cpp:206: DB::PipelineExecutor::finalizeExecution() @ 0x00000000169b13ba 8. /build/src/Processors/Executors/PipelineExecutor.cpp:153: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x00000000169b0584 9. /build/src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:se190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169bfeab 10. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc3d92 11. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fcca080 12. ? @ 0x00007fbc6213eac3 13. ? @ 0x00007fbc621d0850 Job's origin stack trace: 0. /build/src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000000fc33b84 1. /build/src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000000fcc2ea7 2. /build/src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fcc535c 3. /build/src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000000fcc584d 4. /build/src/Common/ThreadPool.h:279: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x00000000169bf193 5. /build/src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x00000000169bf518 6. /build/src/Server/TCPHandler.cpp:1237: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x00000000168f1525 7. /build/src/Server/TCPHandler.cpp:678: DB::TCPHandler::runImpl() @ 0x00000000168e68e5 8. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 9. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 10. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 11. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 12. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 13. ? @ 0x00007fbc6213eac3 14. ? @ 0x00007fbc621d0850 2025.07.28 12:02:08.682626 [ 62058 ] {63fc4b30-ade9-40c8-9977-be9ccd162e47} executeQuery: Code: 394. DB::Exception: Query was cancelled. (QUERY_WAS_CANCELLED) (version 25.3.6.10636.altinitytest (altinity build)) (from [::1]:42388) (comment: 02461_cancel_finish_race.sh) (query 1, line 1) (in query: KILL QUERY WHERE current_database = 'test_dtwle8fg' SYNC FORMAT Null), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000000a074fcb 4. /build/src/Interpreters/ProcessList.cpp:567: DB::QueryStatus::throwQueryWasCancelled() const @ 0x0000000014a4bc85 5. /build/src/Interpreters/ProcessList.cpp:520: DB::QueryStatus::throwProperExceptionIfNeeded(unsigned long const&, unsigned long const&) @ 0x0000000014a4bbd9 6. /build/src/Interpreters/ProcessList.cpp:557: DB::QueryStatus::checkTimeLimit() @ 0x0000000014a4c2cd 7. /build/src/Processors/Executors/PipelineExecutor.cpp:206: DB::PipelineExecutor::finalizeExecution() @ 0x00000000169b13ba 8. /build/src/Processors/Executors/PipelineExecutor.cpp:153: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x00000000169b0584 9. /build/src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:se190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169bfeab 10. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc3d92 11. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fcca080 12. ? @ 0x00007fbc6213eac3 13. ? @ 0x00007fbc621d0850 2025.07.28 12:02:08.689853 [ 62058 ] {} TCPHandler: Code: 394. DB::Exception: Query was cancelled. (QUERY_WAS_CANCELLED), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000000a074fcb 4. /build/src/Interpreters/ProcessList.cpp:567: DB::QueryStatus::throwQueryWasCancelled() const @ 0x0000000014a4bc85 5. /build/src/Interpreters/ProcessList.cpp:520: DB::QueryStatus::throwProperExceptionIfNeeded(unsigned long const&, unsigned long const&) @ 0x0000000014a4bbd9 6. /build/src/Interpreters/ProcessList.cpp:557: DB::QueryStatus::checkTimeLimit() @ 0x0000000014a4c2cd 7. /build/src/Processors/Executors/PipelineExecutor.cpp:206: DB::PipelineExecutor::finalizeExecution() @ 0x00000000169b13ba 8. /build/src/Processors/Executors/PipelineExecutor.cpp:153: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x00000000169b0584 9. /build/src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:se190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169bfeab 10. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc3d92 11. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fcca080 12. ? @ 0x00007fbc6213eac3 13. ? @ 0x00007fbc621d0850 Job's origin stack trace: 0. /build/src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000000fc33b84 1. /build/src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000000fcc2ea7 2. /build/src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fcc535c 3. /build/src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000000fcc584d 4. /build/src/Common/ThreadPool.h:279: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x00000000169bf193 5. /build/src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x00000000169bf518 6. /build/src/Server/TCPHandler.cpp:1237: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x00000000168f1525 7. /build/src/Server/TCPHandler.cpp:678: DB::TCPHandler::runImpl() @ 0x00000000168e68e5 8. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 9. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 10. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 11. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 12. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 13. ? @ 0x00007fbc6213eac3 14. ? @ 0x00007fbc621d0850 2025.07.28 12:02:08.722487 [ 4900 ] {} TCPHandler: Code: 394. DB::Exception: Query was cancelled. (QUERY_WAS_CANCELLED), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000000a074fcb 4. /build/src/Interpreters/ProcessList.cpp:567: DB::QueryStatus::throwQueryWasCancelled() const @ 0x0000000014a4bc85 5. /build/src/Interpreters/ProcessList.cpp:520: DB::QueryStatus::throwProperExceptionIfNeeded(unsigned long const&, unsigned long const&) @ 0x0000000014a4bbd9 6. /build/src/Interpreters/ProcessList.cpp:557: DB::QueryStatus::checkTimeLimit() @ 0x0000000014a4c2cd 7. /build/src/Processors/Executors/PipelineExecutor.cpp:206: DB::PipelineExecutor::finalizeExecution() @ 0x00000000169b13ba 8. /build/src/Processors/Executors/PipelineExecutor.cpp:181: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x00000000169b1726 9. /build/src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x00000000169c081c 10. /build/src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x00000000169c0978 11. /build/src/Interpreters/InterpreterKillQueryQuery.cpp:442: DB::InterpreterKillQueryQuery::getSelectResult(String const&, String const&) @ 0x0000000014cf0f6b 12. /build/src/Interpreters/InterpreterKillQueryQuery.cpp:222: DB::InterpreterKillQueryQuery::execute() @ 0x0000000014cebde2 13. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88dc9 14. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 15. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 16. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 17. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 18. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 19. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 20. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 21. ? @ 0x00007fbc6213eac3 22. ? @ 0x00007fbc621d0850 2025.07.28 12:02:08.729067 [ 3962 ] {} test_13.rmt2 (7f9b740d-015c-470e-8cc6-8ba33be0dc63): auto DB::StorageReplicatedMergeTree::processQueueEntry(ReplicatedMergeTreeQueue::SelectedEntryPtr)::(anonymous class)::operator()(LogEntryPtr &) const: Code: 86. DB::HTTPException: Received error from remote server http://146b4357c08d:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Ftest%2F01165%2Ftest_13%2Frmt%2Freplicas%2F1&part=20250728_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.6.10636.altinitytest (altinity build)) '. (RECEIVED_ERROR_FROM_REMOTE_IO_SERVER), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.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 const&, int&&, String const&, unsigned long&&, String const&) @ 0x000000000feda8d9 4. /build/src/IO/HTTPCommon.cpp:104: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x000000000feda6e2 5. /build/src/IO/HTTPCommon.cpp:93: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x000000000feda537 6. /build/src/IO/ReadWriteBufferFromHTTP.cpp:277: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x000000001184a4c4 7. /build/src/IO/ReadWriteBufferFromHTTP.cpp:285: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x000000001184a615 8. /build/src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x000000001184ae59 9. /build/src/IO/ReadWriteBufferFromHTTP.cpp:472: void std::__function::__policy_invoker::__call_impl[abi:se190107]>(std::__function::__policy_storage const*) @ 0x000000001184cedd 10. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001184858b 11. /build/src/IO/ReadWriteBufferFromHTTP.cpp:465: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x000000001184bf0b 12. /build/src/IO/ReadBuffer.h:60: DB::ReadBuffer::next() @ 0x000000000a148c7b 13. /build/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) @ 0x0000000011849fb2 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]>&)>&, 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&) @ 0x0000000011841980 15. /build/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) @ 0x000000001621208e 16. /build/src/Storages/StorageReplicatedMergeTree.cpp:5228: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl[abi:se190107] const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000015f9a5fe 17. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000015ed8bfd 18. /build/src/Storages/StorageReplicatedMergeTree.cpp:2514: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x0000000015ec9aab 19. /build/src/Storages/StorageReplicatedMergeTree.cpp:2349: DB::StorageReplicatedMergeTree::executeLogEntry(DB::ReplicatedMergeTreeLogEntry&) @ 0x0000000015eba91b 20. /build/src/Storages/StorageReplicatedMergeTree.cpp:3876: bool std::__function::__policy_invoker&)>::__call_impl[abi:se190107])::$_1, bool (std::shared_ptr&)>>(std::__function::__policy_storage const*, std::shared_ptr&) @ 0x0000000015f9837e 21. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000165d6fc3 22. /build/src/Storages/StorageReplicatedMergeTree.cpp:3872: DB::StorageReplicatedMergeTree::processQueueEntry(std::shared_ptr) @ 0x0000000015efc18a 23. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001624c1b2 24. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000162f9c70 25. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x00000000162fa55a 26. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc6653 27. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000000fccc4c3 28. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc3d92 29. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fcca080 30. ? @ 0x00007fbc6213eac3 31. ? @ 0x00007fbc621d0850 (version 25.3.6.10636.altinitytest (altinity build)) 2025.07.28 12:02:09.197622 [ 11826 ] {} TCPHandler: Code: 394. DB::Exception: Query was cancelled. (QUERY_WAS_CANCELLED), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000000a074fcb 4. /build/src/Interpreters/ProcessList.cpp:567: DB::QueryStatus::throwQueryWasCancelled() const @ 0x0000000014a4bc85 5. /build/src/Interpreters/ProcessList.cpp:520: DB::QueryStatus::throwProperExceptionIfNeeded(unsigned long const&, unsigned long const&) @ 0x0000000014a4bbd9 6. /build/src/Interpreters/ProcessList.cpp:557: DB::QueryStatus::checkTimeLimit() @ 0x0000000014a4c2cd 7. /build/src/Processors/Executors/PipelineExecutor.cpp:206: DB::PipelineExecutor::finalizeExecution() @ 0x00000000169b13ba 8. /build/src/Processors/Executors/PipelineExecutor.cpp:181: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x00000000169b1726 9. /build/src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x00000000169c081c 10. /build/src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x00000000169c0978 11. /build/src/Interpreters/InterpreterKillQueryQuery.cpp:442: DB::InterpreterKillQueryQuery::getSelectResult(String const&, String const&) @ 0x0000000014cf0f6b 12. /build/src/Interpreters/InterpreterKillQueryQuery.cpp:222: DB::InterpreterKillQueryQuery::execute() @ 0x0000000014cebde2 13. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88dc9 14. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 15. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 16. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 17. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 18. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 19. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 20. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 21. ? @ 0x00007fbc6213eac3 22. ? @ 0x00007fbc621d0850 2025.07.28 12:02:09.218389 [ 17255 ] {33fa4b9e-389c-46b1-b884-322377e8ce45} executeQuery: Code: 394. DB::Exception: Query was cancelled. (QUERY_WAS_CANCELLED) (version 25.3.6.10636.altinitytest (altinity build)) (from [::1]:42500) (comment: 02461_cancel_finish_race.sh) (query 1, line 1) (in query: KILL QUERY WHERE current_database = 'test_dtwle8fg' SYNC FORMAT Null), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000000a074fcb 4. /build/src/Interpreters/ProcessList.cpp:567: DB::QueryStatus::throwQueryWasCancelled() const @ 0x0000000014a4bc85 5. /build/src/Interpreters/ProcessList.cpp:520: DB::QueryStatus::throwProperExceptionIfNeeded(unsigned long const&, unsigned long const&) @ 0x0000000014a4bbd9 6. /build/src/Interpreters/ProcessList.cpp:557: DB::QueryStatus::checkTimeLimit() @ 0x0000000014a4c2cd 7. /build/src/Processors/Executors/PipelineExecutor.cpp:206: DB::PipelineExecutor::finalizeExecution() @ 0x00000000169b13ba 8. /build/src/Processors/Executors/PipelineExecutor.cpp:153: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x00000000169b0584 9. /build/src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:se190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169bfeab 10. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc3d92 11. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fcca080 12. ? @ 0x00007fbc6213eac3 13. ? @ 0x00007fbc621d0850 2025.07.28 12:02:09.338236 [ 62103 ] {a1483a5e-244a-453b-b5a6-dcba5f4f80fd} executeQuery: Code: 394. DB::Exception: Query was cancelled. (QUERY_WAS_CANCELLED) (version 25.3.6.10636.altinitytest (altinity build)) (from [::1]:42466) (comment: 02461_cancel_finish_race.sh) (query 1, line 1) (in query: KILL QUERY WHERE current_database = 'test_dtwle8fg' SYNC FORMAT Null), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000000a074fcb 4. /build/src/Interpreters/ProcessList.cpp:567: DB::QueryStatus::throwQueryWasCancelled() const @ 0x0000000014a4bc85 5. /build/src/Interpreters/ProcessList.cpp:520: DB::QueryStatus::throwProperExceptionIfNeeded(unsigned long const&, unsigned long const&) @ 0x0000000014a4bbd9 6. /build/src/Interpreters/ProcessList.cpp:557: DB::QueryStatus::checkTimeLimit() @ 0x0000000014a4c2cd 7. /build/src/Processors/Executors/PipelineExecutor.cpp:206: DB::PipelineExecutor::finalizeExecution() @ 0x00000000169b13ba 8. /build/src/Processors/Executors/PipelineExecutor.cpp:153: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x00000000169b0584 9. /build/src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:se190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169bfeab 10. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc3d92 11. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fcca080 12. ? @ 0x00007fbc6213eac3 13. ? @ 0x00007fbc621d0850 2025.07.28 12:02:09.343686 [ 17255 ] {} TCPHandler: Code: 394. DB::Exception: Query was cancelled. (QUERY_WAS_CANCELLED), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000000a074fcb 4. /build/src/Interpreters/ProcessList.cpp:567: DB::QueryStatus::throwQueryWasCancelled() const @ 0x0000000014a4bc85 5. /build/src/Interpreters/ProcessList.cpp:520: DB::QueryStatus::throwProperExceptionIfNeeded(unsigned long const&, unsigned long const&) @ 0x0000000014a4bbd9 6. /build/src/Interpreters/ProcessList.cpp:557: DB::QueryStatus::checkTimeLimit() @ 0x0000000014a4c2cd 7. /build/src/Processors/Executors/PipelineExecutor.cpp:206: DB::PipelineExecutor::finalizeExecution() @ 0x00000000169b13ba 8. /build/src/Processors/Executors/PipelineExecutor.cpp:153: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x00000000169b0584 9. /build/src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:se190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169bfeab 10. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc3d92 11. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fcca080 12. ? @ 0x00007fbc6213eac3 13. ? @ 0x00007fbc621d0850 Job's origin stack trace: 0. /build/src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000000fc33b84 1. /build/src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000000fcc2ea7 2. /build/src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fcc535c 3. /build/src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000000fcc584d 4. /build/src/Common/ThreadPool.h:279: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x00000000169bf193 5. /build/src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x00000000169bf518 6. /build/src/Server/TCPHandler.cpp:1237: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x00000000168f1525 7. /build/src/Server/TCPHandler.cpp:678: DB::TCPHandler::runImpl() @ 0x00000000168e68e5 8. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 9. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 10. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 11. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 12. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 13. ? @ 0x00007fbc6213eac3 14. ? @ 0x00007fbc621d0850 2025.07.28 12:02:09.359994 [ 62103 ] {} TCPHandler: Code: 394. DB::Exception: Query was cancelled. (QUERY_WAS_CANCELLED), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000000a074fcb 4. /build/src/Interpreters/ProcessList.cpp:567: DB::QueryStatus::throwQueryWasCancelled() const @ 0x0000000014a4bc85 5. /build/src/Interpreters/ProcessList.cpp:520: DB::QueryStatus::throwProperExceptionIfNeeded(unsigned long const&, unsigned long const&) @ 0x0000000014a4bbd9 6. /build/src/Interpreters/ProcessList.cpp:557: DB::QueryStatus::checkTimeLimit() @ 0x0000000014a4c2cd 7. /build/src/Processors/Executors/PipelineExecutor.cpp:206: DB::PipelineExecutor::finalizeExecution() @ 0x00000000169b13ba 8. /build/src/Processors/Executors/PipelineExecutor.cpp:153: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x00000000169b0584 9. /build/src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:se190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169bfeab 10. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc3d92 11. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fcca080 12. ? @ 0x00007fbc6213eac3 13. ? @ 0x00007fbc621d0850 Job's origin stack trace: 0. /build/src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000000fc33b84 1. /build/src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000000fcc2ea7 2. /build/src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fcc535c 3. /build/src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000000fcc584d 4. /build/src/Common/ThreadPool.h:279: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x00000000169bf193 5. /build/src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x00000000169bf518 6. /build/src/Server/TCPHandler.cpp:1237: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x00000000168f1525 7. /build/src/Server/TCPHandler.cpp:678: DB::TCPHandler::runImpl() @ 0x00000000168e68e5 8. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 9. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 10. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 11. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 12. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 13. ? @ 0x00007fbc6213eac3 14. ? @ 0x00007fbc621d0850 2025.07.28 12:02:09.361295 [ 62053 ] {} TCPHandler: Code: 394. DB::Exception: Query was cancelled. (QUERY_WAS_CANCELLED), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000000a074fcb 4. /build/src/Interpreters/ProcessList.cpp:567: DB::QueryStatus::throwQueryWasCancelled() const @ 0x0000000014a4bc85 5. /build/src/Interpreters/ProcessList.cpp:520: DB::QueryStatus::throwProperExceptionIfNeeded(unsigned long const&, unsigned long const&) @ 0x0000000014a4bbd9 6. /build/src/Interpreters/ProcessList.cpp:557: DB::QueryStatus::checkTimeLimit() @ 0x0000000014a4c2cd 7. /build/src/Processors/Executors/PipelineExecutor.cpp:206: DB::PipelineExecutor::finalizeExecution() @ 0x00000000169b13ba 8. /build/src/Processors/Executors/PipelineExecutor.cpp:181: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x00000000169b1726 9. /build/src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x00000000169c081c 10. /build/src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x00000000169c0978 11. /build/src/Interpreters/InterpreterKillQueryQuery.cpp:439: DB::InterpreterKillQueryQuery::getSelectResult(String const&, String const&) @ 0x0000000014cf0f04 12. /build/src/Interpreters/InterpreterKillQueryQuery.cpp:222: DB::InterpreterKillQueryQuery::execute() @ 0x0000000014cebde2 13. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88dc9 14. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 15. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 16. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 17. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 18. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 19. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 20. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 21. ? @ 0x00007fbc6213eac3 22. ? @ 0x00007fbc621d0850 2025.07.28 12:02:09.375300 [ 3963 ] {} test_13.rmt2 (7f9b740d-015c-470e-8cc6-8ba33be0dc63): auto DB::StorageReplicatedMergeTree::processQueueEntry(ReplicatedMergeTreeQueue::SelectedEntryPtr)::(anonymous class)::operator()(LogEntryPtr &) const: Code: 86. DB::HTTPException: Received error from remote server http://146b4357c08d:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Ftest%2F01165%2Ftest_13%2Frmt%2Freplicas%2F1&part=20250728_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.6.10636.altinitytest (altinity build)) '. (RECEIVED_ERROR_FROM_REMOTE_IO_SERVER), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.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 const&, int&&, String const&, unsigned long&&, String const&) @ 0x000000000feda8d9 4. /build/src/IO/HTTPCommon.cpp:104: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x000000000feda6e2 5. /build/src/IO/HTTPCommon.cpp:93: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x000000000feda537 6. /build/src/IO/ReadWriteBufferFromHTTP.cpp:277: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x000000001184a4c4 7. /build/src/IO/ReadWriteBufferFromHTTP.cpp:285: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x000000001184a615 8. /build/src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x000000001184ae59 9. /build/src/IO/ReadWriteBufferFromHTTP.cpp:472: void std::__function::__policy_invoker::__call_impl[abi:se190107]>(std::__function::__policy_storage const*) @ 0x000000001184cedd 10. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001184858b 11. /build/src/IO/ReadWriteBufferFromHTTP.cpp:465: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x000000001184bf0b 12. /build/src/IO/ReadBuffer.h:60: DB::ReadBuffer::next() @ 0x000000000a148c7b 13. /build/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) @ 0x0000000011849fb2 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]>&)>&, 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&) @ 0x0000000011841980 15. /build/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) @ 0x000000001621208e 16. /build/src/Storages/StorageReplicatedMergeTree.cpp:5228: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl[abi:se190107] const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000015f9a5fe 17. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000015ed8bfd 18. /build/src/Storages/StorageReplicatedMergeTree.cpp:2514: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x0000000015ec9aab 19. /build/src/Storages/StorageReplicatedMergeTree.cpp:2349: DB::StorageReplicatedMergeTree::executeLogEntry(DB::ReplicatedMergeTreeLogEntry&) @ 0x0000000015eba91b 20. /build/src/Storages/StorageReplicatedMergeTree.cpp:3876: bool std::__function::__policy_invoker&)>::__call_impl[abi:se190107])::$_1, bool (std::shared_ptr&)>>(std::__function::__policy_storage const*, std::shared_ptr&) @ 0x0000000015f9837e 21. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000165d6fc3 22. /build/src/Storages/StorageReplicatedMergeTree.cpp:3872: DB::StorageReplicatedMergeTree::processQueueEntry(std::shared_ptr) @ 0x0000000015efc18a 23. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001624c1b2 24. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000162f9c70 25. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x00000000162fa55a 26. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc6653 27. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000000fccc4c3 28. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc3d92 29. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fcca080 30. ? @ 0x00007fbc6213eac3 31. ? @ 0x00007fbc621d0850 (version 25.3.6.10636.altinitytest (altinity build)) 2025.07.28 12:02:09.407760 [ 17256 ] {3c9c38a0-3ee8-42be-abf4-f05e0fd5d85e} executeQuery: Code: 394. DB::Exception: Query was cancelled. (QUERY_WAS_CANCELLED) (version 25.3.6.10636.altinitytest (altinity build)) (from [::1]:42518) (comment: 02461_cancel_finish_race.sh) (query 1, line 1) (in query: KILL QUERY WHERE current_database = 'test_dtwle8fg' SYNC FORMAT Null), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000000a074fcb 4. /build/src/Interpreters/ProcessList.cpp:567: DB::QueryStatus::throwQueryWasCancelled() const @ 0x0000000014a4bc85 5. /build/src/Interpreters/ProcessList.cpp:520: DB::QueryStatus::throwProperExceptionIfNeeded(unsigned long const&, unsigned long const&) @ 0x0000000014a4bbd9 6. /build/src/Interpreters/ProcessList.cpp:531: DB::QueryStatus::addPipelineExecutor(DB::PipelineExecutor*) @ 0x0000000014a4bd9c 7. /build/src/Processors/Executors/PipelineExecutor.cpp:73: DB::PipelineExecutor::PipelineExecutor(std::shared_ptr, std::allocator>>>&, std::shared_ptr) @ 0x00000000169afe31 8. /build/contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x00000000169bef66 9. /build/src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x00000000169bf518 10. /build/src/Server/TCPHandler.cpp:1237: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x00000000168f1525 11. /build/src/Server/TCPHandler.cpp:678: DB::TCPHandler::runImpl() @ 0x00000000168e68e5 12. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 13. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 14. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 16. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 17. ? @ 0x00007fbc6213eac3 18. ? @ 0x00007fbc621d0850 2025.07.28 12:02:09.417324 [ 17252 ] {a35d52a2-0ed0-411c-8672-58c62cd72578} executeQuery: Code: 394. DB::Exception: Query was cancelled. (QUERY_WAS_CANCELLED) (version 25.3.6.10636.altinitytest (altinity build)) (from [::1]:42598) (comment: 02461_cancel_finish_race.sh) (query 1, line 1) (in query: KILL QUERY WHERE current_database = 'test_dtwle8fg' SYNC FORMAT Null), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000000a074fcb 4. /build/src/Interpreters/ProcessList.cpp:567: DB::QueryStatus::throwQueryWasCancelled() const @ 0x0000000014a4bc85 5. /build/src/Interpreters/ProcessList.cpp:520: DB::QueryStatus::throwProperExceptionIfNeeded(unsigned long const&, unsigned long const&) @ 0x0000000014a4bbd9 6. /build/src/Interpreters/ProcessList.cpp:531: DB::QueryStatus::addPipelineExecutor(DB::PipelineExecutor*) @ 0x0000000014a4bd9c 7. /build/src/Processors/Executors/PipelineExecutor.cpp:73: DB::PipelineExecutor::PipelineExecutor(std::shared_ptr, std::allocator>>>&, std::shared_ptr) @ 0x00000000169afe31 8. /build/contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x00000000169bef66 9. /build/src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x00000000169bf518 10. /build/src/Server/TCPHandler.cpp:1237: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x00000000168f1525 11. /build/src/Server/TCPHandler.cpp:678: DB::TCPHandler::runImpl() @ 0x00000000168e68e5 12. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 13. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 14. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 16. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 17. ? @ 0x00007fbc6213eac3 18. ? @ 0x00007fbc621d0850 2025.07.28 12:02:09.443696 [ 17252 ] {} TCPHandler: Code: 394. DB::Exception: Query was cancelled. (QUERY_WAS_CANCELLED), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000000a074fcb 4. /build/src/Interpreters/ProcessList.cpp:567: DB::QueryStatus::throwQueryWasCancelled() const @ 0x0000000014a4bc85 5. /build/src/Interpreters/ProcessList.cpp:520: DB::QueryStatus::throwProperExceptionIfNeeded(unsigned long const&, unsigned long const&) @ 0x0000000014a4bbd9 6. /build/src/Interpreters/ProcessList.cpp:531: DB::QueryStatus::addPipelineExecutor(DB::PipelineExecutor*) @ 0x0000000014a4bd9c 7. /build/src/Processors/Executors/PipelineExecutor.cpp:73: DB::PipelineExecutor::PipelineExecutor(std::shared_ptr, std::allocator>>>&, std::shared_ptr) @ 0x00000000169afe31 8. /build/contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x00000000169bef66 9. /build/src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x00000000169bf518 10. /build/src/Server/TCPHandler.cpp:1237: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x00000000168f1525 11. /build/src/Server/TCPHandler.cpp:678: DB::TCPHandler::runImpl() @ 0x00000000168e68e5 12. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 13. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 14. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 16. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 17. ? @ 0x00007fbc6213eac3 18. ? @ 0x00007fbc621d0850 2025.07.28 12:02:09.453896 [ 5879 ] {823741b0-316b-4668-8b56-3d0cb4b4ae85} executeQuery: Code: 394. DB::Exception: Query was cancelled. (QUERY_WAS_CANCELLED) (version 25.3.6.10636.altinitytest (altinity build)) (from [::1]:42488) (comment: 02461_cancel_finish_race.sh) (query 1, line 1) (in query: KILL QUERY WHERE current_database = 'test_dtwle8fg' SYNC FORMAT Null), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000000a074fcb 4. /build/src/Interpreters/ProcessList.cpp:567: DB::QueryStatus::throwQueryWasCancelled() const @ 0x0000000014a4bc85 5. /build/src/Interpreters/ProcessList.cpp:520: DB::QueryStatus::throwProperExceptionIfNeeded(unsigned long const&, unsigned long const&) @ 0x0000000014a4bbd9 6. /build/src/Interpreters/ProcessList.cpp:557: DB::QueryStatus::checkTimeLimit() @ 0x0000000014a4c2cd 7. /build/src/Processors/Executors/PipelineExecutor.cpp:206: DB::PipelineExecutor::finalizeExecution() @ 0x00000000169b13ba 8. /build/src/Processors/Executors/PipelineExecutor.cpp:153: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x00000000169b0584 9. /build/src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:se190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169bfeab 10. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc3d92 11. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fcca080 12. ? @ 0x00007fbc6213eac3 13. ? @ 0x00007fbc621d0850 2025.07.28 12:02:09.453953 [ 17256 ] {} TCPHandler: Code: 394. DB::Exception: Query was cancelled. (QUERY_WAS_CANCELLED), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000000a074fcb 4. /build/src/Interpreters/ProcessList.cpp:567: DB::QueryStatus::throwQueryWasCancelled() const @ 0x0000000014a4bc85 5. /build/src/Interpreters/ProcessList.cpp:520: DB::QueryStatus::throwProperExceptionIfNeeded(unsigned long const&, unsigned long const&) @ 0x0000000014a4bbd9 6. /build/src/Interpreters/ProcessList.cpp:531: DB::QueryStatus::addPipelineExecutor(DB::PipelineExecutor*) @ 0x0000000014a4bd9c 7. /build/src/Processors/Executors/PipelineExecutor.cpp:73: DB::PipelineExecutor::PipelineExecutor(std::shared_ptr, std::allocator>>>&, std::shared_ptr) @ 0x00000000169afe31 8. /build/contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x00000000169bef66 9. /build/src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x00000000169bf518 10. /build/src/Server/TCPHandler.cpp:1237: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x00000000168f1525 11. /build/src/Server/TCPHandler.cpp:678: DB::TCPHandler::runImpl() @ 0x00000000168e68e5 12. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 13. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 14. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 16. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 17. ? @ 0x00007fbc6213eac3 18. ? @ 0x00007fbc621d0850 2025.07.28 12:02:09.464270 [ 5879 ] {} TCPHandler: Code: 394. DB::Exception: Query was cancelled. (QUERY_WAS_CANCELLED), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000000a074fcb 4. /build/src/Interpreters/ProcessList.cpp:567: DB::QueryStatus::throwQueryWasCancelled() const @ 0x0000000014a4bc85 5. /build/src/Interpreters/ProcessList.cpp:520: DB::QueryStatus::throwProperExceptionIfNeeded(unsigned long const&, unsigned long const&) @ 0x0000000014a4bbd9 6. /build/src/Interpreters/ProcessList.cpp:557: DB::QueryStatus::checkTimeLimit() @ 0x0000000014a4c2cd 7. /build/src/Processors/Executors/PipelineExecutor.cpp:206: DB::PipelineExecutor::finalizeExecution() @ 0x00000000169b13ba 8. /build/src/Processors/Executors/PipelineExecutor.cpp:153: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x00000000169b0584 9. /build/src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:se190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169bfeab 10. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc3d92 11. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fcca080 12. ? @ 0x00007fbc6213eac3 13. ? @ 0x00007fbc621d0850 Job's origin stack trace: 0. /build/src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000000fc33b84 1. /build/src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000000fcc2ea7 2. /build/src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fcc535c 3. /build/src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000000fcc584d 4. /build/src/Common/ThreadPool.h:279: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x00000000169bf193 5. /build/src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x00000000169bf518 6. /build/src/Server/TCPHandler.cpp:1237: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x00000000168f1525 7. /build/src/Server/TCPHandler.cpp:678: DB::TCPHandler::runImpl() @ 0x00000000168e68e5 8. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 9. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 10. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 11. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 12. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 13. ? @ 0x00007fbc6213eac3 14. ? @ 0x00007fbc621d0850 2025.07.28 12:02:09.648127 [ 62065 ] {5606d28a-9d2c-4a2f-9488-7c8a3c861a83} executeQuery: Code: 394. DB::Exception: Query was cancelled. (QUERY_WAS_CANCELLED) (version 25.3.6.10636.altinitytest (altinity build)) (from [::1]:42622) (comment: 02461_cancel_finish_race.sh) (query 1, line 1) (in query: KILL QUERY WHERE current_database = 'test_dtwle8fg' SYNC FORMAT Null), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000000a074fcb 4. /build/src/Interpreters/ProcessList.cpp:567: DB::QueryStatus::throwQueryWasCancelled() const @ 0x0000000014a4bc85 5. /build/src/Interpreters/ProcessList.cpp:520: DB::QueryStatus::throwProperExceptionIfNeeded(unsigned long const&, unsigned long const&) @ 0x0000000014a4bbd9 6. /build/src/Interpreters/ProcessList.cpp:557: DB::QueryStatus::checkTimeLimit() @ 0x0000000014a4c2cd 7. /build/src/Processors/Executors/PipelineExecutor.cpp:206: DB::PipelineExecutor::finalizeExecution() @ 0x00000000169b13ba 8. /build/src/Processors/Executors/PipelineExecutor.cpp:153: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x00000000169b0584 9. /build/src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:se190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169bfeab 10. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc3d92 11. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fcca080 12. ? @ 0x00007fbc6213eac3 13. ? @ 0x00007fbc621d0850 2025.07.28 12:02:09.772435 [ 62065 ] {} TCPHandler: Code: 394. DB::Exception: Query was cancelled. (QUERY_WAS_CANCELLED), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000000a074fcb 4. /build/src/Interpreters/ProcessList.cpp:567: DB::QueryStatus::throwQueryWasCancelled() const @ 0x0000000014a4bc85 5. /build/src/Interpreters/ProcessList.cpp:520: DB::QueryStatus::throwProperExceptionIfNeeded(unsigned long const&, unsigned long const&) @ 0x0000000014a4bbd9 6. /build/src/Interpreters/ProcessList.cpp:557: DB::QueryStatus::checkTimeLimit() @ 0x0000000014a4c2cd 7. /build/src/Processors/Executors/PipelineExecutor.cpp:206: DB::PipelineExecutor::finalizeExecution() @ 0x00000000169b13ba 8. /build/src/Processors/Executors/PipelineExecutor.cpp:153: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x00000000169b0584 9. /build/src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:se190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169bfeab 10. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc3d92 11. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fcca080 12. ? @ 0x00007fbc6213eac3 13. ? @ 0x00007fbc621d0850 Job's origin stack trace: 0. /build/src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000000fc33b84 1. /build/src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000000fcc2ea7 2. /build/src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fcc535c 3. /build/src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000000fcc584d 4. /build/src/Common/ThreadPool.h:279: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x00000000169bf193 5. /build/src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x00000000169bf518 6. /build/src/Server/TCPHandler.cpp:1237: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x00000000168f1525 7. /build/src/Server/TCPHandler.cpp:678: DB::TCPHandler::runImpl() @ 0x00000000168e68e5 8. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 9. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 10. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 11. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 12. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 13. ? @ 0x00007fbc6213eac3 14. ? @ 0x00007fbc621d0850 2025.07.28 12:02:10.005688 [ 62058 ] {15330bdf-2cc6-49b6-a95c-c4778b140181} executeQuery: Code: 394. DB::Exception: Query was cancelled. (QUERY_WAS_CANCELLED) (version 25.3.6.10636.altinitytest (altinity build)) (from [::1]:42692) (comment: 02461_cancel_finish_race.sh) (query 1, line 1) (in query: KILL QUERY WHERE current_database = 'test_dtwle8fg' SYNC FORMAT Null), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000000a074fcb 4. /build/src/Interpreters/ProcessList.cpp:567: DB::QueryStatus::throwQueryWasCancelled() const @ 0x0000000014a4bc85 5. /build/src/Interpreters/ProcessList.cpp:520: DB::QueryStatus::throwProperExceptionIfNeeded(unsigned long const&, unsigned long const&) @ 0x0000000014a4bbd9 6. /build/src/Interpreters/ProcessList.cpp:531: DB::QueryStatus::addPipelineExecutor(DB::PipelineExecutor*) @ 0x0000000014a4bd9c 7. /build/src/Processors/Executors/PipelineExecutor.cpp:73: DB::PipelineExecutor::PipelineExecutor(std::shared_ptr, std::allocator>>>&, std::shared_ptr) @ 0x00000000169afe31 8. /build/contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x00000000169bef66 9. /build/src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x00000000169bf518 10. /build/src/Server/TCPHandler.cpp:1237: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x00000000168f1525 11. /build/src/Server/TCPHandler.cpp:678: DB::TCPHandler::runImpl() @ 0x00000000168e68e5 12. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 13. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 14. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 16. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 17. ? @ 0x00007fbc6213eac3 18. ? @ 0x00007fbc621d0850 2025.07.28 12:02:10.022665 [ 62058 ] {} TCPHandler: Code: 394. DB::Exception: Query was cancelled. (QUERY_WAS_CANCELLED), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000000a074fcb 4. /build/src/Interpreters/ProcessList.cpp:567: DB::QueryStatus::throwQueryWasCancelled() const @ 0x0000000014a4bc85 5. /build/src/Interpreters/ProcessList.cpp:520: DB::QueryStatus::throwProperExceptionIfNeeded(unsigned long const&, unsigned long const&) @ 0x0000000014a4bbd9 6. /build/src/Interpreters/ProcessList.cpp:531: DB::QueryStatus::addPipelineExecutor(DB::PipelineExecutor*) @ 0x0000000014a4bd9c 7. /build/src/Processors/Executors/PipelineExecutor.cpp:73: DB::PipelineExecutor::PipelineExecutor(std::shared_ptr, std::allocator>>>&, std::shared_ptr) @ 0x00000000169afe31 8. /build/contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x00000000169bef66 9. /build/src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x00000000169bf518 10. /build/src/Server/TCPHandler.cpp:1237: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x00000000168f1525 11. /build/src/Server/TCPHandler.cpp:678: DB::TCPHandler::runImpl() @ 0x00000000168e68e5 12. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 13. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 14. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 16. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 17. ? @ 0x00007fbc6213eac3 18. ? @ 0x00007fbc621d0850 2025.07.28 12:02:10.152176 [ 17255 ] {cfc2bff4-9e49-44e7-8bef-d3e433b78f66} executeQuery: Code: 394. DB::Exception: Query was cancelled. (QUERY_WAS_CANCELLED) (version 25.3.6.10636.altinitytest (altinity build)) (from [::1]:42720) (comment: 02461_cancel_finish_race.sh) (query 1, line 1) (in query: KILL QUERY WHERE current_database = 'test_dtwle8fg' SYNC FORMAT Null), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000000a074fcb 4. /build/src/Interpreters/ProcessList.cpp:567: DB::QueryStatus::throwQueryWasCancelled() const @ 0x0000000014a4bc85 5. /build/src/Interpreters/ProcessList.cpp:520: DB::QueryStatus::throwProperExceptionIfNeeded(unsigned long const&, unsigned long const&) @ 0x0000000014a4bbd9 6. /build/src/Interpreters/ProcessList.cpp:557: DB::QueryStatus::checkTimeLimit() @ 0x0000000014a4c2cd 7. /build/src/Processors/Executors/PipelineExecutor.cpp:206: DB::PipelineExecutor::finalizeExecution() @ 0x00000000169b13ba 8. /build/src/Processors/Executors/PipelineExecutor.cpp:153: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x00000000169b0584 9. /build/src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:se190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169bfeab 10. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc3d92 11. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fcca080 12. ? @ 0x00007fbc6213eac3 13. ? @ 0x00007fbc621d0850 2025.07.28 12:02:10.159464 [ 17255 ] {} TCPHandler: Code: 394. DB::Exception: Query was cancelled. (QUERY_WAS_CANCELLED), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000000a074fcb 4. /build/src/Interpreters/ProcessList.cpp:567: DB::QueryStatus::throwQueryWasCancelled() const @ 0x0000000014a4bc85 5. /build/src/Interpreters/ProcessList.cpp:520: DB::QueryStatus::throwProperExceptionIfNeeded(unsigned long const&, unsigned long const&) @ 0x0000000014a4bbd9 6. /build/src/Interpreters/ProcessList.cpp:557: DB::QueryStatus::checkTimeLimit() @ 0x0000000014a4c2cd 7. /build/src/Processors/Executors/PipelineExecutor.cpp:206: DB::PipelineExecutor::finalizeExecution() @ 0x00000000169b13ba 8. /build/src/Processors/Executors/PipelineExecutor.cpp:153: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x00000000169b0584 9. /build/src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:se190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169bfeab 10. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc3d92 11. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fcca080 12. ? @ 0x00007fbc6213eac3 13. ? @ 0x00007fbc621d0850 Job's origin stack trace: 0. /build/src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000000fc33b84 1. /build/src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000000fcc2ea7 2. /build/src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fcc535c 3. /build/src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000000fcc584d 4. /build/src/Common/ThreadPool.h:279: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x00000000169bf193 5. /build/src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x00000000169bf518 6. /build/src/Server/TCPHandler.cpp:1237: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x00000000168f1525 7. /build/src/Server/TCPHandler.cpp:678: DB::TCPHandler::runImpl() @ 0x00000000168e68e5 8. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 9. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 10. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 11. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 12. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 13. ? @ 0x00007fbc6213eac3 14. ? @ 0x00007fbc621d0850 2025.07.28 12:02:10.177794 [ 17256 ] {5ffd1a17-f593-4d57-85b3-60325921cc5a} executeQuery: Code: 394. DB::Exception: Query was cancelled. (QUERY_WAS_CANCELLED) (version 25.3.6.10636.altinitytest (altinity build)) (from [::1]:42776) (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. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000000a074fcb 4. /build/src/Interpreters/ProcessList.cpp:567: DB::QueryStatus::throwQueryWasCancelled() const @ 0x0000000014a4bc85 5. /build/src/Interpreters/ProcessList.cpp:520: DB::QueryStatus::throwProperExceptionIfNeeded(unsigned long const&, unsigned long const&) @ 0x0000000014a4bbd9 6. /build/src/Interpreters/ProcessList.cpp:557: DB::QueryStatus::checkTimeLimit() @ 0x0000000014a4c2cd 7. /build/src/Processors/Executors/PipelineExecutor.cpp:206: DB::PipelineExecutor::finalizeExecution() @ 0x00000000169b13ba 8. /build/src/Processors/Executors/PipelineExecutor.cpp:153: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x00000000169b0584 9. /build/src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:se190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169bfeab 10. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc3d92 11. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fcca080 12. ? @ 0x00007fbc6213eac3 13. ? @ 0x00007fbc621d0850 2025.07.28 12:02:10.189344 [ 62057 ] {93f0b789-c491-4391-9151-02546b72ed8d} executeQuery: Code: 394. DB::Exception: Query was cancelled. (QUERY_WAS_CANCELLED) (version 25.3.6.10636.altinitytest (altinity build)) (from [::1]:42804) (comment: 02461_cancel_finish_race.sh) (query 1, line 1) (in query: KILL QUERY WHERE current_database = 'test_dtwle8fg' SYNC FORMAT Null), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000000a074fcb 4. /build/src/Interpreters/ProcessList.cpp:567: DB::QueryStatus::throwQueryWasCancelled() const @ 0x0000000014a4bc85 5. /build/src/Interpreters/ProcessList.cpp:520: DB::QueryStatus::throwProperExceptionIfNeeded(unsigned long const&, unsigned long const&) @ 0x0000000014a4bbd9 6. /build/src/Interpreters/ProcessList.cpp:557: DB::QueryStatus::checkTimeLimit() @ 0x0000000014a4c2cd 7. /build/src/Processors/Executors/PipelineExecutor.cpp:206: DB::PipelineExecutor::finalizeExecution() @ 0x00000000169b13ba 8. /build/src/Processors/Executors/PipelineExecutor.cpp:153: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x00000000169b0584 9. /build/src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:se190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169bfeab 10. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc3d92 11. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fcca080 12. ? @ 0x00007fbc6213eac3 13. ? @ 0x00007fbc621d0850 2025.07.28 12:02:10.190322 [ 17256 ] {} TCPHandler: Code: 394. DB::Exception: Query was cancelled. (QUERY_WAS_CANCELLED), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000000a074fcb 4. /build/src/Interpreters/ProcessList.cpp:567: DB::QueryStatus::throwQueryWasCancelled() const @ 0x0000000014a4bc85 5. /build/src/Interpreters/ProcessList.cpp:520: DB::QueryStatus::throwProperExceptionIfNeeded(unsigned long const&, unsigned long const&) @ 0x0000000014a4bbd9 6. /build/src/Interpreters/ProcessList.cpp:557: DB::QueryStatus::checkTimeLimit() @ 0x0000000014a4c2cd 7. /build/src/Processors/Executors/PipelineExecutor.cpp:206: DB::PipelineExecutor::finalizeExecution() @ 0x00000000169b13ba 8. /build/src/Processors/Executors/PipelineExecutor.cpp:153: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x00000000169b0584 9. /build/src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:se190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169bfeab 10. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc3d92 11. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fcca080 12. ? @ 0x00007fbc6213eac3 13. ? @ 0x00007fbc621d0850 Job's origin stack trace: 0. /build/src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000000fc33b84 1. /build/src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000000fcc2ea7 2. /build/src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fcc535c 3. /build/src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000000fcc584d 4. /build/src/Common/ThreadPool.h:279: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x00000000169bf193 5. /build/src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x00000000169bf518 6. /build/src/Server/TCPHandler.cpp:1237: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x00000000168f1525 7. /build/src/Server/TCPHandler.cpp:678: DB::TCPHandler::runImpl() @ 0x00000000168e68e5 8. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 9. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 10. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 11. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 12. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 13. ? @ 0x00007fbc6213eac3 14. ? @ 0x00007fbc621d0850 2025.07.28 12:02:10.190699 [ 4900 ] {15cdac6c-ac10-4b61-9ce6-f6571256250c} executeQuery: Code: 394. DB::Exception: Query was cancelled. (QUERY_WAS_CANCELLED) (version 25.3.6.10636.altinitytest (altinity build)) (from [::1]:42710) (comment: 02461_cancel_finish_race.sh) (query 1, line 1) (in query: KILL QUERY WHERE current_database = 'test_dtwle8fg' SYNC FORMAT Null), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000000a074fcb 4. /build/src/Interpreters/ProcessList.cpp:567: DB::QueryStatus::throwQueryWasCancelled() const @ 0x0000000014a4bc85 5. /build/src/Interpreters/ProcessList.cpp:520: DB::QueryStatus::throwProperExceptionIfNeeded(unsigned long const&, unsigned long const&) @ 0x0000000014a4bbd9 6. /build/src/Interpreters/ProcessList.cpp:557: DB::QueryStatus::checkTimeLimit() @ 0x0000000014a4c2cd 7. /build/src/Processors/Executors/PipelineExecutor.cpp:206: DB::PipelineExecutor::finalizeExecution() @ 0x00000000169b13ba 8. /build/src/Processors/Executors/PipelineExecutor.cpp:153: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x00000000169b0584 9. /build/src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:se190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169bfeab 10. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc3d92 11. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fcca080 12. ? @ 0x00007fbc6213eac3 13. ? @ 0x00007fbc621d0850 2025.07.28 12:02:10.201852 [ 62103 ] {dec86b93-2726-48b4-97c7-f85b6c56307d} executeQuery: Code: 394. DB::Exception: Query was cancelled. (QUERY_WAS_CANCELLED) (version 25.3.6.10636.altinitytest (altinity build)) (from [::1]:42810) (comment: 02461_cancel_finish_race.sh) (query 1, line 1) (in query: KILL QUERY WHERE current_database = 'test_dtwle8fg' SYNC FORMAT Null), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000000a074fcb 4. /build/src/Interpreters/ProcessList.cpp:567: DB::QueryStatus::throwQueryWasCancelled() const @ 0x0000000014a4bc85 5. /build/src/Interpreters/ProcessList.cpp:520: DB::QueryStatus::throwProperExceptionIfNeeded(unsigned long const&, unsigned long const&) @ 0x0000000014a4bbd9 6. /build/src/Interpreters/ProcessList.cpp:557: DB::QueryStatus::checkTimeLimit() @ 0x0000000014a4c2cd 7. /build/src/Processors/Executors/PipelineExecutor.cpp:206: DB::PipelineExecutor::finalizeExecution() @ 0x00000000169b13ba 8. /build/src/Processors/Executors/PipelineExecutor.cpp:153: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x00000000169b0584 9. /build/src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:se190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169bfeab 10. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc3d92 11. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fcca080 12. ? @ 0x00007fbc6213eac3 13. ? @ 0x00007fbc621d0850 2025.07.28 12:02:10.221537 [ 17232 ] {} TCPHandler: Code: 394. DB::Exception: Query was cancelled. (QUERY_WAS_CANCELLED), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000000a074fcb 4. /build/src/Interpreters/ProcessList.cpp:567: DB::QueryStatus::throwQueryWasCancelled() const @ 0x0000000014a4bc85 5. /build/src/Interpreters/ProcessList.cpp:520: DB::QueryStatus::throwProperExceptionIfNeeded(unsigned long const&, unsigned long const&) @ 0x0000000014a4bbd9 6. /build/src/Interpreters/ProcessList.cpp:557: DB::QueryStatus::checkTimeLimit() @ 0x0000000014a4c2cd 7. /build/src/Processors/Executors/PipelineExecutor.cpp:206: DB::PipelineExecutor::finalizeExecution() @ 0x00000000169b13ba 8. /build/src/Processors/Executors/PipelineExecutor.cpp:181: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x00000000169b1726 9. /build/src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x00000000169c081c 10. /build/src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x00000000169c0978 11. /build/src/Interpreters/InterpreterKillQueryQuery.cpp:439: DB::InterpreterKillQueryQuery::getSelectResult(String const&, String const&) @ 0x0000000014cf0f04 12. /build/src/Interpreters/InterpreterKillQueryQuery.cpp:222: DB::InterpreterKillQueryQuery::execute() @ 0x0000000014cebde2 13. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88dc9 14. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 15. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 16. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 17. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 18. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 19. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 20. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 21. ? @ 0x00007fbc6213eac3 22. ? @ 0x00007fbc621d0850 2025.07.28 12:02:10.262025 [ 62057 ] {} TCPHandler: Code: 394. DB::Exception: Query was cancelled. (QUERY_WAS_CANCELLED), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000000a074fcb 4. /build/src/Interpreters/ProcessList.cpp:567: DB::QueryStatus::throwQueryWasCancelled() const @ 0x0000000014a4bc85 5. /build/src/Interpreters/ProcessList.cpp:520: DB::QueryStatus::throwProperExceptionIfNeeded(unsigned long const&, unsigned long const&) @ 0x0000000014a4bbd9 6. /build/src/Interpreters/ProcessList.cpp:557: DB::QueryStatus::checkTimeLimit() @ 0x0000000014a4c2cd 7. /build/src/Processors/Executors/PipelineExecutor.cpp:206: DB::PipelineExecutor::finalizeExecution() @ 0x00000000169b13ba 8. /build/src/Processors/Executors/PipelineExecutor.cpp:153: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x00000000169b0584 9. /build/src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:se190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169bfeab 10. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc3d92 11. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fcca080 12. ? @ 0x00007fbc6213eac3 13. ? @ 0x00007fbc621d0850 Job's origin stack trace: 0. /build/src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000000fc33b84 1. /build/src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000000fcc2ea7 2. /build/src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fcc535c 3. /build/src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000000fcc584d 4. /build/src/Common/ThreadPool.h:279: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x00000000169bf193 5. /build/src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x00000000169bf518 6. /build/src/Server/TCPHandler.cpp:1237: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x00000000168f1525 7. /build/src/Server/TCPHandler.cpp:678: DB::TCPHandler::runImpl() @ 0x00000000168e68e5 8. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 9. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 10. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 11. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 12. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 13. ? @ 0x00007fbc6213eac3 14. ? @ 0x00007fbc621d0850 2025.07.28 12:02:10.324291 [ 62103 ] {} TCPHandler: Code: 394. DB::Exception: Query was cancelled. (QUERY_WAS_CANCELLED), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000000a074fcb 4. /build/src/Interpreters/ProcessList.cpp:567: DB::QueryStatus::throwQueryWasCancelled() const @ 0x0000000014a4bc85 5. /build/src/Interpreters/ProcessList.cpp:520: DB::QueryStatus::throwProperExceptionIfNeeded(unsigned long const&, unsigned long const&) @ 0x0000000014a4bbd9 6. /build/src/Interpreters/ProcessList.cpp:557: DB::QueryStatus::checkTimeLimit() @ 0x0000000014a4c2cd 7. /build/src/Processors/Executors/PipelineExecutor.cpp:206: DB::PipelineExecutor::finalizeExecution() @ 0x00000000169b13ba 8. /build/src/Processors/Executors/PipelineExecutor.cpp:153: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x00000000169b0584 9. /build/src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:se190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169bfeab 10. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc3d92 11. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fcca080 12. ? @ 0x00007fbc6213eac3 13. ? @ 0x00007fbc621d0850 Job's origin stack trace: 0. /build/src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000000fc33b84 1. /build/src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000000fcc2ea7 2. /build/src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fcc535c 3. /build/src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000000fcc584d 4. /build/src/Common/ThreadPool.h:279: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x00000000169bf193 5. /build/src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x00000000169bf518 6. /build/src/Server/TCPHandler.cpp:1237: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x00000000168f1525 7. /build/src/Server/TCPHandler.cpp:678: DB::TCPHandler::runImpl() @ 0x00000000168e68e5 8. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 9. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 10. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 11. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 12. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 13. ? @ 0x00007fbc6213eac3 14. ? @ 0x00007fbc621d0850 2025.07.28 12:02:10.325531 [ 4900 ] {} TCPHandler: Code: 394. DB::Exception: Query was cancelled. (QUERY_WAS_CANCELLED), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000000a074fcb 4. /build/src/Interpreters/ProcessList.cpp:567: DB::QueryStatus::throwQueryWasCancelled() const @ 0x0000000014a4bc85 5. /build/src/Interpreters/ProcessList.cpp:520: DB::QueryStatus::throwProperExceptionIfNeeded(unsigned long const&, unsigned long const&) @ 0x0000000014a4bbd9 6. /build/src/Interpreters/ProcessList.cpp:557: DB::QueryStatus::checkTimeLimit() @ 0x0000000014a4c2cd 7. /build/src/Processors/Executors/PipelineExecutor.cpp:206: DB::PipelineExecutor::finalizeExecution() @ 0x00000000169b13ba 8. /build/src/Processors/Executors/PipelineExecutor.cpp:153: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x00000000169b0584 9. /build/src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:se190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169bfeab 10. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc3d92 11. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fcca080 12. ? @ 0x00007fbc6213eac3 13. ? @ 0x00007fbc621d0850 Job's origin stack trace: 0. /build/src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000000fc33b84 1. /build/src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000000fcc2ea7 2. /build/src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fcc535c 3. /build/src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000000fcc584d 4. /build/src/Common/ThreadPool.h:279: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x00000000169bf193 5. /build/src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x00000000169bf518 6. /build/src/Server/TCPHandler.cpp:1237: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x00000000168f1525 7. /build/src/Server/TCPHandler.cpp:678: DB::TCPHandler::runImpl() @ 0x00000000168e68e5 8. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 9. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 10. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 11. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 12. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 13. ? @ 0x00007fbc6213eac3 14. ? @ 0x00007fbc621d0850 2025.07.28 12:02:10.329465 [ 62053 ] {214c3cf8-0752-43ea-b97c-4b0ea99505c8} executeQuery: Code: 394. DB::Exception: Query was cancelled. (QUERY_WAS_CANCELLED) (version 25.3.6.10636.altinitytest (altinity build)) (from [::1]:42798) (comment: 02461_cancel_finish_race.sh) (query 1, line 1) (in query: KILL QUERY WHERE current_database = 'test_dtwle8fg' SYNC FORMAT Null), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000000a074fcb 4. /build/src/Interpreters/ProcessList.cpp:567: DB::QueryStatus::throwQueryWasCancelled() const @ 0x0000000014a4bc85 5. /build/src/Interpreters/ProcessList.cpp:520: DB::QueryStatus::throwProperExceptionIfNeeded(unsigned long const&, unsigned long const&) @ 0x0000000014a4bbd9 6. /build/src/Interpreters/ProcessList.cpp:557: DB::QueryStatus::checkTimeLimit() @ 0x0000000014a4c2cd 7. /build/src/Processors/Executors/PipelineExecutor.cpp:206: DB::PipelineExecutor::finalizeExecution() @ 0x00000000169b13ba 8. /build/src/Processors/Executors/PipelineExecutor.cpp:153: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x00000000169b0584 9. /build/src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:se190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169bfeab 10. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc3d92 11. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fcca080 12. ? @ 0x00007fbc6213eac3 13. ? @ 0x00007fbc621d0850 2025.07.28 12:02:10.344810 [ 62053 ] {} TCPHandler: Code: 394. DB::Exception: Query was cancelled. (QUERY_WAS_CANCELLED), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000000a074fcb 4. /build/src/Interpreters/ProcessList.cpp:567: DB::QueryStatus::throwQueryWasCancelled() const @ 0x0000000014a4bc85 5. /build/src/Interpreters/ProcessList.cpp:520: DB::QueryStatus::throwProperExceptionIfNeeded(unsigned long const&, unsigned long const&) @ 0x0000000014a4bbd9 6. /build/src/Interpreters/ProcessList.cpp:557: DB::QueryStatus::checkTimeLimit() @ 0x0000000014a4c2cd 7. /build/src/Processors/Executors/PipelineExecutor.cpp:206: DB::PipelineExecutor::finalizeExecution() @ 0x00000000169b13ba 8. /build/src/Processors/Executors/PipelineExecutor.cpp:153: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x00000000169b0584 9. /build/src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:se190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169bfeab 10. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc3d92 11. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fcca080 12. ? @ 0x00007fbc6213eac3 13. ? @ 0x00007fbc621d0850 Job's origin stack trace: 0. /build/src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000000fc33b84 1. /build/src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000000fcc2ea7 2. /build/src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fcc535c 3. /build/src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000000fcc584d 4. /build/src/Common/ThreadPool.h:279: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x00000000169bf193 5. /build/src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x00000000169bf518 6. /build/src/Server/TCPHandler.cpp:1237: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x00000000168f1525 7. /build/src/Server/TCPHandler.cpp:678: DB::TCPHandler::runImpl() @ 0x00000000168e68e5 8. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 9. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 10. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 11. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 12. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 13. ? @ 0x00007fbc6213eac3 14. ? @ 0x00007fbc621d0850 2025.07.28 12:02:10.348957 [ 3972 ] {} test_13.rmt2 (7f9b740d-015c-470e-8cc6-8ba33be0dc63): auto DB::StorageReplicatedMergeTree::processQueueEntry(ReplicatedMergeTreeQueue::SelectedEntryPtr)::(anonymous class)::operator()(LogEntryPtr &) const: Code: 86. DB::HTTPException: Received error from remote server http://146b4357c08d:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Ftest%2F01165%2Ftest_13%2Frmt%2Freplicas%2F1&part=20250728_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.6.10636.altinitytest (altinity build)) '. (RECEIVED_ERROR_FROM_REMOTE_IO_SERVER), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.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 const&, int&&, String const&, unsigned long&&, String const&) @ 0x000000000feda8d9 4. /build/src/IO/HTTPCommon.cpp:104: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x000000000feda6e2 5. /build/src/IO/HTTPCommon.cpp:93: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x000000000feda537 6. /build/src/IO/ReadWriteBufferFromHTTP.cpp:277: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x000000001184a4c4 7. /build/src/IO/ReadWriteBufferFromHTTP.cpp:285: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x000000001184a615 8. /build/src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x000000001184ae59 9. /build/src/IO/ReadWriteBufferFromHTTP.cpp:472: void std::__function::__policy_invoker::__call_impl[abi:se190107]>(std::__function::__policy_storage const*) @ 0x000000001184cedd 10. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001184858b 11. /build/src/IO/ReadWriteBufferFromHTTP.cpp:465: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x000000001184bf0b 12. /build/src/IO/ReadBuffer.h:60: DB::ReadBuffer::next() @ 0x000000000a148c7b 13. /build/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) @ 0x0000000011849fb2 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]>&)>&, 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&) @ 0x0000000011841980 15. /build/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) @ 0x000000001621208e 16. /build/src/Storages/StorageReplicatedMergeTree.cpp:5228: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl[abi:se190107] const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000015f9a5fe 17. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000015ed8bfd 18. /build/src/Storages/StorageReplicatedMergeTree.cpp:2514: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x0000000015ec9aab 19. /build/src/Storages/StorageReplicatedMergeTree.cpp:2349: DB::StorageReplicatedMergeTree::executeLogEntry(DB::ReplicatedMergeTreeLogEntry&) @ 0x0000000015eba91b 20. /build/src/Storages/StorageReplicatedMergeTree.cpp:3876: bool std::__function::__policy_invoker&)>::__call_impl[abi:se190107])::$_1, bool (std::shared_ptr&)>>(std::__function::__policy_storage const*, std::shared_ptr&) @ 0x0000000015f9837e 21. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000165d6fc3 22. /build/src/Storages/StorageReplicatedMergeTree.cpp:3872: DB::StorageReplicatedMergeTree::processQueueEntry(std::shared_ptr) @ 0x0000000015efc18a 23. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001624c1b2 24. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000162f9c70 25. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x00000000162fa55a 26. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc6653 27. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000000fccc4c3 28. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc3d92 29. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fcca080 30. ? @ 0x00007fbc6213eac3 31. ? @ 0x00007fbc621d0850 (version 25.3.6.10636.altinitytest (altinity build)) 2025.07.28 12:02:10.556373 [ 11826 ] {} TCPHandler: Code: 394. DB::Exception: Query was cancelled. (QUERY_WAS_CANCELLED), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000000a074fcb 4. /build/src/Interpreters/ProcessList.cpp:567: DB::QueryStatus::throwQueryWasCancelled() const @ 0x0000000014a4bc85 5. /build/src/Interpreters/ProcessList.cpp:520: DB::QueryStatus::throwProperExceptionIfNeeded(unsigned long const&, unsigned long const&) @ 0x0000000014a4bbd9 6. /build/src/Interpreters/ProcessList.cpp:557: DB::QueryStatus::checkTimeLimit() @ 0x0000000014a4c2cd 7. /build/src/Processors/Executors/PipelineExecutor.cpp:206: DB::PipelineExecutor::finalizeExecution() @ 0x00000000169b13ba 8. /build/src/Processors/Executors/PipelineExecutor.cpp:181: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x00000000169b1726 9. /build/src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x00000000169c081c 10. /build/src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x00000000169c0978 11. /build/src/Interpreters/InterpreterKillQueryQuery.cpp:442: DB::InterpreterKillQueryQuery::getSelectResult(String const&, String const&) @ 0x0000000014cf0f6b 12. /build/src/Interpreters/InterpreterKillQueryQuery.cpp:222: DB::InterpreterKillQueryQuery::execute() @ 0x0000000014cebde2 13. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88dc9 14. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 15. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 16. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 17. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 18. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 19. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 20. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 21. ? @ 0x00007fbc6213eac3 22. ? @ 0x00007fbc621d0850 2025.07.28 12:02:10.565857 [ 62114 ] {b1a61191-0748-458a-a33a-c5cd47d48153} executeQuery: Code: 394. DB::Exception: Query was cancelled. (QUERY_WAS_CANCELLED) (version 25.3.6.10636.altinitytest (altinity build)) (from [::1]:42866) (comment: 02461_cancel_finish_race.sh) (query 1, line 1) (in query: KILL QUERY WHERE current_database = 'test_dtwle8fg' SYNC FORMAT Null), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000000a074fcb 4. /build/src/Interpreters/ProcessList.cpp:567: DB::QueryStatus::throwQueryWasCancelled() const @ 0x0000000014a4bc85 5. /build/src/Interpreters/ProcessList.cpp:520: DB::QueryStatus::throwProperExceptionIfNeeded(unsigned long const&, unsigned long const&) @ 0x0000000014a4bbd9 6. /build/src/Interpreters/ProcessList.cpp:557: DB::QueryStatus::checkTimeLimit() @ 0x0000000014a4c2cd 7. /build/src/Processors/Executors/PipelineExecutor.cpp:206: DB::PipelineExecutor::finalizeExecution() @ 0x00000000169b13ba 8. /build/src/Processors/Executors/PipelineExecutor.cpp:153: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x00000000169b0584 9. /build/src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:se190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169bfeab 10. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc3d92 11. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fcca080 12. ? @ 0x00007fbc6213eac3 13. ? @ 0x00007fbc621d0850 2025.07.28 12:02:10.576889 [ 62114 ] {} TCPHandler: Code: 394. DB::Exception: Query was cancelled. (QUERY_WAS_CANCELLED), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000000a074fcb 4. /build/src/Interpreters/ProcessList.cpp:567: DB::QueryStatus::throwQueryWasCancelled() const @ 0x0000000014a4bc85 5. /build/src/Interpreters/ProcessList.cpp:520: DB::QueryStatus::throwProperExceptionIfNeeded(unsigned long const&, unsigned long const&) @ 0x0000000014a4bbd9 6. /build/src/Interpreters/ProcessList.cpp:557: DB::QueryStatus::checkTimeLimit() @ 0x0000000014a4c2cd 7. /build/src/Processors/Executors/PipelineExecutor.cpp:206: DB::PipelineExecutor::finalizeExecution() @ 0x00000000169b13ba 8. /build/src/Processors/Executors/PipelineExecutor.cpp:153: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x00000000169b0584 9. /build/src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:se190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169bfeab 10. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc3d92 11. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fcca080 12. ? @ 0x00007fbc6213eac3 13. ? @ 0x00007fbc621d0850 Job's origin stack trace: 0. /build/src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000000fc33b84 1. /build/src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000000fcc2ea7 2. /build/src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fcc535c 3. /build/src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000000fcc584d 4. /build/src/Common/ThreadPool.h:279: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x00000000169bf193 5. /build/src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x00000000169bf518 6. /build/src/Server/TCPHandler.cpp:1237: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x00000000168f1525 7. /build/src/Server/TCPHandler.cpp:678: DB::TCPHandler::runImpl() @ 0x00000000168e68e5 8. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 9. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 10. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 11. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 12. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 13. ? @ 0x00007fbc6213eac3 14. ? @ 0x00007fbc621d0850 2025.07.28 12:02:10.614334 [ 4446 ] {1378ddad-9808-41c7-96eb-c0c4ae2163de} executeQuery: Code: 394. DB::Exception: Query was cancelled. (QUERY_WAS_CANCELLED) (version 25.3.6.10636.altinitytest (altinity build)) (from [::1]:42816) (comment: 02461_cancel_finish_race.sh) (query 1, line 1) (in query: KILL QUERY WHERE current_database = 'test_dtwle8fg' SYNC FORMAT Null), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000000a074fcb 4. /build/src/Interpreters/ProcessList.cpp:567: DB::QueryStatus::throwQueryWasCancelled() const @ 0x0000000014a4bc85 5. /build/src/Interpreters/ProcessList.cpp:520: DB::QueryStatus::throwProperExceptionIfNeeded(unsigned long const&, unsigned long const&) @ 0x0000000014a4bbd9 6. /build/src/Interpreters/ProcessList.cpp:557: DB::QueryStatus::checkTimeLimit() @ 0x0000000014a4c2cd 7. /build/src/Processors/Executors/PipelineExecutor.cpp:206: DB::PipelineExecutor::finalizeExecution() @ 0x00000000169b13ba 8. /build/src/Processors/Executors/PipelineExecutor.cpp:153: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x00000000169b0584 9. /build/src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:se190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169bfeab 10. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc3d92 11. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fcca080 12. ? @ 0x00007fbc6213eac3 13. ? @ 0x00007fbc621d0850 2025.07.28 12:02:10.648638 [ 4446 ] {} TCPHandler: Code: 394. DB::Exception: Query was cancelled. (QUERY_WAS_CANCELLED), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000000a074fcb 4. /build/src/Interpreters/ProcessList.cpp:567: DB::QueryStatus::throwQueryWasCancelled() const @ 0x0000000014a4bc85 5. /build/src/Interpreters/ProcessList.cpp:520: DB::QueryStatus::throwProperExceptionIfNeeded(unsigned long const&, unsigned long const&) @ 0x0000000014a4bbd9 6. /build/src/Interpreters/ProcessList.cpp:557: DB::QueryStatus::checkTimeLimit() @ 0x0000000014a4c2cd 7. /build/src/Processors/Executors/PipelineExecutor.cpp:206: DB::PipelineExecutor::finalizeExecution() @ 0x00000000169b13ba 8. /build/src/Processors/Executors/PipelineExecutor.cpp:153: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x00000000169b0584 9. /build/src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:se190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169bfeab 10. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc3d92 11. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fcca080 12. ? @ 0x00007fbc6213eac3 13. ? @ 0x00007fbc621d0850 Job's origin stack trace: 0. /build/src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000000fc33b84 1. /build/src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000000fcc2ea7 2. /build/src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fcc535c 3. /build/src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000000fcc584d 4. /build/src/Common/ThreadPool.h:279: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x00000000169bf193 5. /build/src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x00000000169bf518 6. /build/src/Server/TCPHandler.cpp:1237: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x00000000168f1525 7. /build/src/Server/TCPHandler.cpp:678: DB::TCPHandler::runImpl() @ 0x00000000168e68e5 8. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 9. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 10. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 11. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 12. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 13. ? @ 0x00007fbc6213eac3 14. ? @ 0x00007fbc621d0850 2025.07.28 12:02:10.776502 [ 3967 ] {} test_13.rmt2 (7f9b740d-015c-470e-8cc6-8ba33be0dc63): auto DB::StorageReplicatedMergeTree::processQueueEntry(ReplicatedMergeTreeQueue::SelectedEntryPtr)::(anonymous class)::operator()(LogEntryPtr &) const: Code: 86. DB::HTTPException: Received error from remote server http://146b4357c08d:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Ftest%2F01165%2Ftest_13%2Frmt%2Freplicas%2F1&part=20250728_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.6.10636.altinitytest (altinity build)) '. (RECEIVED_ERROR_FROM_REMOTE_IO_SERVER), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.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 const&, int&&, String const&, unsigned long&&, String const&) @ 0x000000000feda8d9 4. /build/src/IO/HTTPCommon.cpp:104: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x000000000feda6e2 5. /build/src/IO/HTTPCommon.cpp:93: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x000000000feda537 6. /build/src/IO/ReadWriteBufferFromHTTP.cpp:277: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x000000001184a4c4 7. /build/src/IO/ReadWriteBufferFromHTTP.cpp:285: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x000000001184a615 8. /build/src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x000000001184ae59 9. /build/src/IO/ReadWriteBufferFromHTTP.cpp:472: void std::__function::__policy_invoker::__call_impl[abi:se190107]>(std::__function::__policy_storage const*) @ 0x000000001184cedd 10. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001184858b 11. /build/src/IO/ReadWriteBufferFromHTTP.cpp:465: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x000000001184bf0b 12. /build/src/IO/ReadBuffer.h:60: DB::ReadBuffer::next() @ 0x000000000a148c7b 13. /build/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) @ 0x0000000011849fb2 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]>&)>&, 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&) @ 0x0000000011841980 15. /build/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) @ 0x000000001621208e 16. /build/src/Storages/StorageReplicatedMergeTree.cpp:5228: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl[abi:se190107] const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000015f9a5fe 17. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000015ed8bfd 18. /build/src/Storages/StorageReplicatedMergeTree.cpp:2514: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x0000000015ec9aab 19. /build/src/Storages/StorageReplicatedMergeTree.cpp:2349: DB::StorageReplicatedMergeTree::executeLogEntry(DB::ReplicatedMergeTreeLogEntry&) @ 0x0000000015eba91b 20. /build/src/Storages/StorageReplicatedMergeTree.cpp:3876: bool std::__function::__policy_invoker&)>::__call_impl[abi:se190107])::$_1, bool (std::shared_ptr&)>>(std::__function::__policy_storage const*, std::shared_ptr&) @ 0x0000000015f9837e 21. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000165d6fc3 22. /build/src/Storages/StorageReplicatedMergeTree.cpp:3872: DB::StorageReplicatedMergeTree::processQueueEntry(std::shared_ptr) @ 0x0000000015efc18a 23. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001624c1b2 24. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000162f9c70 25. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x00000000162fa55a 26. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc6653 27. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000000fccc4c3 28. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc3d92 29. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fcca080 30. ? @ 0x00007fbc6213eac3 31. ? @ 0x00007fbc621d0850 (version 25.3.6.10636.altinitytest (altinity build)) 2025.07.28 12:02:10.853846 [ 17255 ] {6c3dd142-a93c-4d28-8761-3598887f7e20} executeQuery: Code: 394. DB::Exception: Query was cancelled. (QUERY_WAS_CANCELLED) (version 25.3.6.10636.altinitytest (altinity build)) (from [::1]:42936) (comment: 02461_cancel_finish_race.sh) (query 1, line 1) (in query: KILL QUERY WHERE current_database = 'test_dtwle8fg' SYNC FORMAT Null), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000000a074fcb 4. /build/src/Interpreters/ProcessList.cpp:567: DB::QueryStatus::throwQueryWasCancelled() const @ 0x0000000014a4bc85 5. /build/src/Interpreters/ProcessList.cpp:520: DB::QueryStatus::throwProperExceptionIfNeeded(unsigned long const&, unsigned long const&) @ 0x0000000014a4bbd9 6. /build/src/Interpreters/ProcessList.cpp:557: DB::QueryStatus::checkTimeLimit() @ 0x0000000014a4c2cd 7. /build/src/Processors/Executors/PipelineExecutor.cpp:206: DB::PipelineExecutor::finalizeExecution() @ 0x00000000169b13ba 8. /build/src/Processors/Executors/PipelineExecutor.cpp:153: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x00000000169b0584 9. /build/src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:se190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169bfeab 10. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc3d92 11. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fcca080 12. ? @ 0x00007fbc6213eac3 13. ? @ 0x00007fbc621d0850 2025.07.28 12:02:10.869702 [ 17255 ] {} TCPHandler: Code: 394. DB::Exception: Query was cancelled. (QUERY_WAS_CANCELLED), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000000a074fcb 4. /build/src/Interpreters/ProcessList.cpp:567: DB::QueryStatus::throwQueryWasCancelled() const @ 0x0000000014a4bc85 5. /build/src/Interpreters/ProcessList.cpp:520: DB::QueryStatus::throwProperExceptionIfNeeded(unsigned long const&, unsigned long const&) @ 0x0000000014a4bbd9 6. /build/src/Interpreters/ProcessList.cpp:557: DB::QueryStatus::checkTimeLimit() @ 0x0000000014a4c2cd 7. /build/src/Processors/Executors/PipelineExecutor.cpp:206: DB::PipelineExecutor::finalizeExecution() @ 0x00000000169b13ba 8. /build/src/Processors/Executors/PipelineExecutor.cpp:153: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x00000000169b0584 9. /build/src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:se190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169bfeab 10. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc3d92 11. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fcca080 12. ? @ 0x00007fbc6213eac3 13. ? @ 0x00007fbc621d0850 Job's origin stack trace: 0. /build/src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000000fc33b84 1. /build/src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000000fcc2ea7 2. /build/src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fcc535c 3. /build/src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000000fcc584d 4. /build/src/Common/ThreadPool.h:279: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x00000000169bf193 5. /build/src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x00000000169bf518 6. /build/src/Server/TCPHandler.cpp:1237: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x00000000168f1525 7. /build/src/Server/TCPHandler.cpp:678: DB::TCPHandler::runImpl() @ 0x00000000168e68e5 8. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 9. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 10. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 11. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 12. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 13. ? @ 0x00007fbc6213eac3 14. ? @ 0x00007fbc621d0850 2025.07.28 12:02:10.901565 [ 62093 ] {5cc40898-416c-49b2-aa1e-036f74c82ae9} executeQuery: Code: 394. DB::Exception: Query was cancelled. (QUERY_WAS_CANCELLED) (version 25.3.6.10636.altinitytest (altinity build)) (from [::1]:42946) (comment: 02461_cancel_finish_race.sh) (query 1, line 1) (in query: KILL QUERY WHERE current_database = 'test_dtwle8fg' SYNC FORMAT Null), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000000a074fcb 4. /build/src/Interpreters/ProcessList.cpp:567: DB::QueryStatus::throwQueryWasCancelled() const @ 0x0000000014a4bc85 5. /build/src/Interpreters/ProcessList.cpp:520: DB::QueryStatus::throwProperExceptionIfNeeded(unsigned long const&, unsigned long const&) @ 0x0000000014a4bbd9 6. /build/src/Interpreters/ProcessList.cpp:557: DB::QueryStatus::checkTimeLimit() @ 0x0000000014a4c2cd 7. /build/src/Processors/Executors/PipelineExecutor.cpp:206: DB::PipelineExecutor::finalizeExecution() @ 0x00000000169b13ba 8. /build/src/Processors/Executors/PipelineExecutor.cpp:153: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x00000000169b0584 9. /build/src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:se190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169bfeab 10. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc3d92 11. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fcca080 12. ? @ 0x00007fbc6213eac3 13. ? @ 0x00007fbc621d0850 2025.07.28 12:02:10.911872 [ 62093 ] {} TCPHandler: Code: 394. DB::Exception: Query was cancelled. (QUERY_WAS_CANCELLED), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000000a074fcb 4. /build/src/Interpreters/ProcessList.cpp:567: DB::QueryStatus::throwQueryWasCancelled() const @ 0x0000000014a4bc85 5. /build/src/Interpreters/ProcessList.cpp:520: DB::QueryStatus::throwProperExceptionIfNeeded(unsigned long const&, unsigned long const&) @ 0x0000000014a4bbd9 6. /build/src/Interpreters/ProcessList.cpp:557: DB::QueryStatus::checkTimeLimit() @ 0x0000000014a4c2cd 7. /build/src/Processors/Executors/PipelineExecutor.cpp:206: DB::PipelineExecutor::finalizeExecution() @ 0x00000000169b13ba 8. /build/src/Processors/Executors/PipelineExecutor.cpp:153: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x00000000169b0584 9. /build/src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:se190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169bfeab 10. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc3d92 11. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fcca080 12. ? @ 0x00007fbc6213eac3 13. ? @ 0x00007fbc621d0850 Job's origin stack trace: 0. /build/src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000000fc33b84 1. /build/src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000000fcc2ea7 2. /build/src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fcc535c 3. /build/src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000000fcc584d 4. /build/src/Common/ThreadPool.h:279: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x00000000169bf193 5. /build/src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x00000000169bf518 6. /build/src/Server/TCPHandler.cpp:1237: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x00000000168f1525 7. /build/src/Server/TCPHandler.cpp:678: DB::TCPHandler::runImpl() @ 0x00000000168e68e5 8. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 9. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 10. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 11. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 12. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 13. ? @ 0x00007fbc6213eac3 14. ? @ 0x00007fbc621d0850 2025.07.28 12:02:10.928990 [ 62053 ] {d677fb84-e2ec-4c9c-943f-9ca2cdf57445} executeQuery: Code: 394. DB::Exception: Query was cancelled. (QUERY_WAS_CANCELLED) (version 25.3.6.10636.altinitytest (altinity build)) (from [::1]:43004) (comment: 02461_cancel_finish_race.sh) (query 1, line 1) (in query: KILL QUERY WHERE current_database = 'test_dtwle8fg' SYNC FORMAT Null), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000000a074fcb 4. /build/src/Interpreters/ProcessList.cpp:567: DB::QueryStatus::throwQueryWasCancelled() const @ 0x0000000014a4bc85 5. /build/src/Interpreters/ProcessList.cpp:520: DB::QueryStatus::throwProperExceptionIfNeeded(unsigned long const&, unsigned long const&) @ 0x0000000014a4bbd9 6. /build/src/Interpreters/ProcessList.cpp:557: DB::QueryStatus::checkTimeLimit() @ 0x0000000014a4c2cd 7. /build/src/Processors/Executors/PipelineExecutor.cpp:206: DB::PipelineExecutor::finalizeExecution() @ 0x00000000169b13ba 8. /build/src/Processors/Executors/PipelineExecutor.cpp:153: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x00000000169b0584 9. /build/src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:se190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169bfeab 10. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc3d92 11. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fcca080 12. ? @ 0x00007fbc6213eac3 13. ? @ 0x00007fbc621d0850 2025.07.28 12:02:10.949679 [ 62056 ] {aeb97599-39be-4178-8187-3c8ec782c207} executeQuery: Code: 394. DB::Exception: Query was cancelled. (QUERY_WAS_CANCELLED) (version 25.3.6.10636.altinitytest (altinity build)) (from [::1]:43028) (comment: 02461_cancel_finish_race.sh) (query 1, line 1) (in query: KILL QUERY WHERE current_database = 'test_dtwle8fg' SYNC FORMAT Null), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000000a074fcb 4. /build/src/Interpreters/ProcessList.cpp:567: DB::QueryStatus::throwQueryWasCancelled() const @ 0x0000000014a4bc85 5. /build/src/Interpreters/ProcessList.cpp:520: DB::QueryStatus::throwProperExceptionIfNeeded(unsigned long const&, unsigned long const&) @ 0x0000000014a4bbd9 6. /build/src/Interpreters/ProcessList.cpp:557: DB::QueryStatus::checkTimeLimit() @ 0x0000000014a4c2cd 7. /build/src/Processors/Executors/PipelineExecutor.cpp:206: DB::PipelineExecutor::finalizeExecution() @ 0x00000000169b13ba 8. /build/src/Processors/Executors/PipelineExecutor.cpp:153: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x00000000169b0584 9. /build/src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:se190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169bfeab 10. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc3d92 11. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fcca080 12. ? @ 0x00007fbc6213eac3 13. ? @ 0x00007fbc621d0850 2025.07.28 12:02:10.950353 [ 62053 ] {} TCPHandler: Code: 394. DB::Exception: Query was cancelled. (QUERY_WAS_CANCELLED), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000000a074fcb 4. /build/src/Interpreters/ProcessList.cpp:567: DB::QueryStatus::throwQueryWasCancelled() const @ 0x0000000014a4bc85 5. /build/src/Interpreters/ProcessList.cpp:520: DB::QueryStatus::throwProperExceptionIfNeeded(unsigned long const&, unsigned long const&) @ 0x0000000014a4bbd9 6. /build/src/Interpreters/ProcessList.cpp:557: DB::QueryStatus::checkTimeLimit() @ 0x0000000014a4c2cd 7. /build/src/Processors/Executors/PipelineExecutor.cpp:206: DB::PipelineExecutor::finalizeExecution() @ 0x00000000169b13ba 8. /build/src/Processors/Executors/PipelineExecutor.cpp:153: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x00000000169b0584 9. /build/src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:se190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169bfeab 10. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc3d92 11. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fcca080 12. ? @ 0x00007fbc6213eac3 13. ? @ 0x00007fbc621d0850 Job's origin stack trace: 0. /build/src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000000fc33b84 1. /build/src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000000fcc2ea7 2. /build/src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fcc535c 3. /build/src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000000fcc584d 4. /build/src/Common/ThreadPool.h:279: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x00000000169bf193 5. /build/src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x00000000169bf518 6. /build/src/Server/TCPHandler.cpp:1237: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x00000000168f1525 7. /build/src/Server/TCPHandler.cpp:678: DB::TCPHandler::runImpl() @ 0x00000000168e68e5 8. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 9. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 10. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 11. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 12. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 13. ? @ 0x00007fbc6213eac3 14. ? @ 0x00007fbc621d0850 2025.07.28 12:02:10.951480 [ 17243 ] {bba38723-ee3c-48e7-b510-0956938fa060} executeQuery: Code: 394. DB::Exception: Query was cancelled. (QUERY_WAS_CANCELLED) (version 25.3.6.10636.altinitytest (altinity build)) (from [::1]:42990) (comment: 02461_cancel_finish_race.sh) (query 1, line 1) (in query: KILL QUERY WHERE current_database = 'test_dtwle8fg' SYNC FORMAT Null), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000000a074fcb 4. /build/src/Interpreters/ProcessList.cpp:567: DB::QueryStatus::throwQueryWasCancelled() const @ 0x0000000014a4bc85 5. /build/src/Interpreters/ProcessList.cpp:520: DB::QueryStatus::throwProperExceptionIfNeeded(unsigned long const&, unsigned long const&) @ 0x0000000014a4bbd9 6. /build/src/Interpreters/ProcessList.cpp:557: DB::QueryStatus::checkTimeLimit() @ 0x0000000014a4c2cd 7. /build/src/Processors/Executors/PipelineExecutor.cpp:206: DB::PipelineExecutor::finalizeExecution() @ 0x00000000169b13ba 8. /build/src/Processors/Executors/PipelineExecutor.cpp:153: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x00000000169b0584 9. /build/src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:se190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169bfeab 10. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc3d92 11. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fcca080 12. ? @ 0x00007fbc6213eac3 13. ? @ 0x00007fbc621d0850 2025.07.28 12:02:10.962335 [ 17252 ] {a6200093-8bda-4a29-a2e5-c4feafead062} executeQuery: Code: 394. DB::Exception: Query was cancelled. (QUERY_WAS_CANCELLED) (version 25.3.6.10636.altinitytest (altinity build)) (from [::1]:42982) (comment: 02461_cancel_finish_race.sh) (query 1, line 1) (in query: KILL QUERY WHERE current_database = 'test_dtwle8fg' SYNC FORMAT Null), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000000a074fcb 4. /build/src/Interpreters/ProcessList.cpp:567: DB::QueryStatus::throwQueryWasCancelled() const @ 0x0000000014a4bc85 5. /build/src/Interpreters/ProcessList.cpp:520: DB::QueryStatus::throwProperExceptionIfNeeded(unsigned long const&, unsigned long const&) @ 0x0000000014a4bbd9 6. /build/src/Interpreters/ProcessList.cpp:557: DB::QueryStatus::checkTimeLimit() @ 0x0000000014a4c2cd 7. /build/src/Processors/Executors/PipelineExecutor.cpp:206: DB::PipelineExecutor::finalizeExecution() @ 0x00000000169b13ba 8. /build/src/Processors/Executors/PipelineExecutor.cpp:153: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x00000000169b0584 9. /build/src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:se190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169bfeab 10. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc3d92 11. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fcca080 12. ? @ 0x00007fbc6213eac3 13. ? @ 0x00007fbc621d0850 2025.07.28 12:02:10.978299 [ 17252 ] {} TCPHandler: Code: 394. DB::Exception: Query was cancelled. (QUERY_WAS_CANCELLED), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000000a074fcb 4. /build/src/Interpreters/ProcessList.cpp:567: DB::QueryStatus::throwQueryWasCancelled() const @ 0x0000000014a4bc85 5. /build/src/Interpreters/ProcessList.cpp:520: DB::QueryStatus::throwProperExceptionIfNeeded(unsigned long const&, unsigned long const&) @ 0x0000000014a4bbd9 6. /build/src/Interpreters/ProcessList.cpp:557: DB::QueryStatus::checkTimeLimit() @ 0x0000000014a4c2cd 7. /build/src/Processors/Executors/PipelineExecutor.cpp:206: DB::PipelineExecutor::finalizeExecution() @ 0x00000000169b13ba 8. /build/src/Processors/Executors/PipelineExecutor.cpp:153: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x00000000169b0584 9. /build/src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:se190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169bfeab 10. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc3d92 11. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fcca080 12. ? @ 0x00007fbc6213eac3 13. ? @ 0x00007fbc621d0850 Job's origin stack trace: 0. /build/src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000000fc33b84 1. /build/src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000000fcc2ea7 2. /build/src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fcc535c 3. /build/src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000000fcc584d 4. /build/src/Common/ThreadPool.h:279: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x00000000169bf193 5. /build/src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x00000000169bf518 6. /build/src/Server/TCPHandler.cpp:1237: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x00000000168f1525 7. /build/src/Server/TCPHandler.cpp:678: DB::TCPHandler::runImpl() @ 0x00000000168e68e5 8. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 9. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 10. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 11. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 12. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 13. ? @ 0x00007fbc6213eac3 14. ? @ 0x00007fbc621d0850 2025.07.28 12:02:11.008390 [ 17243 ] {} TCPHandler: Code: 394. DB::Exception: Query was cancelled. (QUERY_WAS_CANCELLED), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000000a074fcb 4. /build/src/Interpreters/ProcessList.cpp:567: DB::QueryStatus::throwQueryWasCancelled() const @ 0x0000000014a4bc85 5. /build/src/Interpreters/ProcessList.cpp:520: DB::QueryStatus::throwProperExceptionIfNeeded(unsigned long const&, unsigned long const&) @ 0x0000000014a4bbd9 6. /build/src/Interpreters/ProcessList.cpp:557: DB::QueryStatus::checkTimeLimit() @ 0x0000000014a4c2cd 7. /build/src/Processors/Executors/PipelineExecutor.cpp:206: DB::PipelineExecutor::finalizeExecution() @ 0x00000000169b13ba 8. /build/src/Processors/Executors/PipelineExecutor.cpp:153: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x00000000169b0584 9. /build/src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:se190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169bfeab 10. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc3d92 11. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fcca080 12. ? @ 0x00007fbc6213eac3 13. ? @ 0x00007fbc621d0850 Job's origin stack trace: 0. /build/src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000000fc33b84 1. /build/src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000000fcc2ea7 2. /build/src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fcc535c 3. /build/src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000000fcc584d 4. /build/src/Common/ThreadPool.h:279: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x00000000169bf193 5. /build/src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x00000000169bf518 6. /build/src/Server/TCPHandler.cpp:1237: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x00000000168f1525 7. /build/src/Server/TCPHandler.cpp:678: DB::TCPHandler::runImpl() @ 0x00000000168e68e5 8. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 9. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 10. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 11. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 12. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 13. ? @ 0x00007fbc6213eac3 14. ? @ 0x00007fbc621d0850 2025.07.28 12:02:11.136233 [ 62056 ] {} TCPHandler: Code: 394. DB::Exception: Query was cancelled. (QUERY_WAS_CANCELLED), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000000a074fcb 4. /build/src/Interpreters/ProcessList.cpp:567: DB::QueryStatus::throwQueryWasCancelled() const @ 0x0000000014a4bc85 5. /build/src/Interpreters/ProcessList.cpp:520: DB::QueryStatus::throwProperExceptionIfNeeded(unsigned long const&, unsigned long const&) @ 0x0000000014a4bbd9 6. /build/src/Interpreters/ProcessList.cpp:557: DB::QueryStatus::checkTimeLimit() @ 0x0000000014a4c2cd 7. /build/src/Processors/Executors/PipelineExecutor.cpp:206: DB::PipelineExecutor::finalizeExecution() @ 0x00000000169b13ba 8. /build/src/Processors/Executors/PipelineExecutor.cpp:153: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x00000000169b0584 9. /build/src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:se190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169bfeab 10. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc3d92 11. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fcca080 12. ? @ 0x00007fbc6213eac3 13. ? @ 0x00007fbc621d0850 Job's origin stack trace: 0. /build/src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000000fc33b84 1. /build/src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000000fcc2ea7 2. /build/src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fcc535c 3. /build/src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000000fcc584d 4. /build/src/Common/ThreadPool.h:279: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x00000000169bf193 5. /build/src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x00000000169bf518 6. /build/src/Server/TCPHandler.cpp:1237: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x00000000168f1525 7. /build/src/Server/TCPHandler.cpp:678: DB::TCPHandler::runImpl() @ 0x00000000168e68e5 8. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 9. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 10. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 11. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 12. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 13. ? @ 0x00007fbc6213eac3 14. ? @ 0x00007fbc621d0850 2025.07.28 12:02:11.310023 [ 4446 ] {2b279cf1-683e-4486-9b47-3b583d9f1a53} executeQuery: Code: 394. DB::Exception: Query was cancelled. (QUERY_WAS_CANCELLED) (version 25.3.6.10636.altinitytest (altinity build)) (from [::1]:43058) (comment: 02461_cancel_finish_race.sh) (query 1, line 1) (in query: KILL QUERY WHERE current_database = 'test_dtwle8fg' SYNC FORMAT Null), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000000a074fcb 4. /build/src/Interpreters/ProcessList.cpp:567: DB::QueryStatus::throwQueryWasCancelled() const @ 0x0000000014a4bc85 5. /build/src/Interpreters/ProcessList.cpp:520: DB::QueryStatus::throwProperExceptionIfNeeded(unsigned long const&, unsigned long const&) @ 0x0000000014a4bbd9 6. /build/src/Interpreters/ProcessList.cpp:557: DB::QueryStatus::checkTimeLimit() @ 0x0000000014a4c2cd 7. /build/src/Processors/Executors/PipelineExecutor.cpp:206: DB::PipelineExecutor::finalizeExecution() @ 0x00000000169b13ba 8. /build/src/Processors/Executors/PipelineExecutor.cpp:153: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x00000000169b0584 9. /build/src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:se190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169bfeab 10. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc3d92 11. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fcca080 12. ? @ 0x00007fbc6213eac3 13. ? @ 0x00007fbc621d0850 2025.07.28 12:02:11.319512 [ 4446 ] {} TCPHandler: Code: 394. DB::Exception: Query was cancelled. (QUERY_WAS_CANCELLED), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000000a074fcb 4. /build/src/Interpreters/ProcessList.cpp:567: DB::QueryStatus::throwQueryWasCancelled() const @ 0x0000000014a4bc85 5. /build/src/Interpreters/ProcessList.cpp:520: DB::QueryStatus::throwProperExceptionIfNeeded(unsigned long const&, unsigned long const&) @ 0x0000000014a4bbd9 6. /build/src/Interpreters/ProcessList.cpp:557: DB::QueryStatus::checkTimeLimit() @ 0x0000000014a4c2cd 7. /build/src/Processors/Executors/PipelineExecutor.cpp:206: DB::PipelineExecutor::finalizeExecution() @ 0x00000000169b13ba 8. /build/src/Processors/Executors/PipelineExecutor.cpp:153: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x00000000169b0584 9. /build/src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:se190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169bfeab 10. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc3d92 11. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fcca080 12. ? @ 0x00007fbc6213eac3 13. ? @ 0x00007fbc621d0850 Job's origin stack trace: 0. /build/src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000000fc33b84 1. /build/src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000000fcc2ea7 2. /build/src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fcc535c 3. /build/src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000000fcc584d 4. /build/src/Common/ThreadPool.h:279: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x00000000169bf193 5. /build/src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x00000000169bf518 6. /build/src/Server/TCPHandler.cpp:1237: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x00000000168f1525 7. /build/src/Server/TCPHandler.cpp:678: DB::TCPHandler::runImpl() @ 0x00000000168e68e5 8. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 9. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 10. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 11. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 12. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 13. ? @ 0x00007fbc6213eac3 14. ? @ 0x00007fbc621d0850 2025.07.28 12:02:11.330289 [ 62057 ] {9264db3d-b2fe-4332-b6a1-2e971a1f3775} executeQuery: Code: 394. DB::Exception: Query was cancelled. (QUERY_WAS_CANCELLED) (version 25.3.6.10636.altinitytest (altinity build)) (from [::1]:43080) (comment: 02461_cancel_finish_race.sh) (query 1, line 1) (in query: KILL QUERY WHERE current_database = 'test_dtwle8fg' SYNC FORMAT Null), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000000a074fcb 4. /build/src/Interpreters/ProcessList.cpp:567: DB::QueryStatus::throwQueryWasCancelled() const @ 0x0000000014a4bc85 5. /build/src/Interpreters/ProcessList.cpp:520: DB::QueryStatus::throwProperExceptionIfNeeded(unsigned long const&, unsigned long const&) @ 0x0000000014a4bbd9 6. /build/src/Interpreters/ProcessList.cpp:557: DB::QueryStatus::checkTimeLimit() @ 0x0000000014a4c2cd 7. /build/src/Processors/Executors/PipelineExecutor.cpp:206: DB::PipelineExecutor::finalizeExecution() @ 0x00000000169b13ba 8. /build/src/Processors/Executors/PipelineExecutor.cpp:153: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x00000000169b0584 9. /build/src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:se190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169bfeab 10. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc3d92 11. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fcca080 12. ? @ 0x00007fbc6213eac3 13. ? @ 0x00007fbc621d0850 2025.07.28 12:02:11.330595 [ 7625 ] {bcecd774-979f-4e74-9bc6-956cd96198d8} executeQuery: Code: 394. DB::Exception: Query was cancelled. (QUERY_WAS_CANCELLED) (version 25.3.6.10636.altinitytest (altinity build)) (from [::1]:43084) (comment: 02461_cancel_finish_race.sh) (query 1, line 1) (in query: KILL QUERY WHERE current_database = 'test_dtwle8fg' SYNC FORMAT Null), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000000a074fcb 4. /build/src/Interpreters/ProcessList.cpp:567: DB::QueryStatus::throwQueryWasCancelled() const @ 0x0000000014a4bc85 5. /build/src/Interpreters/ProcessList.cpp:520: DB::QueryStatus::throwProperExceptionIfNeeded(unsigned long const&, unsigned long const&) @ 0x0000000014a4bbd9 6. /build/src/Interpreters/ProcessList.cpp:557: DB::QueryStatus::checkTimeLimit() @ 0x0000000014a4c2cd 7. /build/src/Processors/Executors/PipelineExecutor.cpp:206: DB::PipelineExecutor::finalizeExecution() @ 0x00000000169b13ba 8. /build/src/Processors/Executors/PipelineExecutor.cpp:153: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x00000000169b0584 9. /build/src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:se190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169bfeab 10. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc3d92 11. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fcca080 12. ? @ 0x00007fbc6213eac3 13. ? @ 0x00007fbc621d0850 2025.07.28 12:02:11.341250 [ 62057 ] {} TCPHandler: Code: 394. DB::Exception: Query was cancelled. (QUERY_WAS_CANCELLED), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000000a074fcb 4. /build/src/Interpreters/ProcessList.cpp:567: DB::QueryStatus::throwQueryWasCancelled() const @ 0x0000000014a4bc85 5. /build/src/Interpreters/ProcessList.cpp:520: DB::QueryStatus::throwProperExceptionIfNeeded(unsigned long const&, unsigned long const&) @ 0x0000000014a4bbd9 6. /build/src/Interpreters/ProcessList.cpp:557: DB::QueryStatus::checkTimeLimit() @ 0x0000000014a4c2cd 7. /build/src/Processors/Executors/PipelineExecutor.cpp:206: DB::PipelineExecutor::finalizeExecution() @ 0x00000000169b13ba 8. /build/src/Processors/Executors/PipelineExecutor.cpp:153: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x00000000169b0584 9. /build/src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:se190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169bfeab 10. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc3d92 11. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fcca080 12. ? @ 0x00007fbc6213eac3 13. ? @ 0x00007fbc621d0850 Job's origin stack trace: 0. /build/src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000000fc33b84 1. /build/src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000000fcc2ea7 2. /build/src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fcc535c 3. /build/src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000000fcc584d 4. /build/src/Common/ThreadPool.h:279: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x00000000169bf193 5. /build/src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x00000000169bf518 6. /build/src/Server/TCPHandler.cpp:1237: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x00000000168f1525 7. /build/src/Server/TCPHandler.cpp:678: DB::TCPHandler::runImpl() @ 0x00000000168e68e5 8. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 9. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 10. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 11. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 12. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 13. ? @ 0x00007fbc6213eac3 14. ? @ 0x00007fbc621d0850 2025.07.28 12:02:11.365212 [ 7625 ] {} TCPHandler: Code: 394. DB::Exception: Query was cancelled. (QUERY_WAS_CANCELLED), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000000a074fcb 4. /build/src/Interpreters/ProcessList.cpp:567: DB::QueryStatus::throwQueryWasCancelled() const @ 0x0000000014a4bc85 5. /build/src/Interpreters/ProcessList.cpp:520: DB::QueryStatus::throwProperExceptionIfNeeded(unsigned long const&, unsigned long const&) @ 0x0000000014a4bbd9 6. /build/src/Interpreters/ProcessList.cpp:557: DB::QueryStatus::checkTimeLimit() @ 0x0000000014a4c2cd 7. /build/src/Processors/Executors/PipelineExecutor.cpp:206: DB::PipelineExecutor::finalizeExecution() @ 0x00000000169b13ba 8. /build/src/Processors/Executors/PipelineExecutor.cpp:153: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x00000000169b0584 9. /build/src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:se190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169bfeab 10. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc3d92 11. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fcca080 12. ? @ 0x00007fbc6213eac3 13. ? @ 0x00007fbc621d0850 Job's origin stack trace: 0. /build/src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000000fc33b84 1. /build/src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000000fcc2ea7 2. /build/src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fcc535c 3. /build/src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000000fcc584d 4. /build/src/Common/ThreadPool.h:279: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x00000000169bf193 5. /build/src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x00000000169bf518 6. /build/src/Server/TCPHandler.cpp:1237: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x00000000168f1525 7. /build/src/Server/TCPHandler.cpp:678: DB::TCPHandler::runImpl() @ 0x00000000168e68e5 8. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 9. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 10. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 11. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 12. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 13. ? @ 0x00007fbc6213eac3 14. ? @ 0x00007fbc621d0850 2025.07.28 12:02:11.679779 [ 5879 ] {d0d39da6-6f6d-4d2a-96fe-295d258fd0ce} executeQuery: Code: 433. DB::Exception: Delta codec argument must be unsigned integer. (ILLEGAL_CODEC_PARAMETER) (version 25.3.6.10636.altinitytest (altinity build)) (from [::1]:43074) (comment: 01296_codecs_bad_arguments.sql) (query 4, line 5) (in query: CREATE TABLE delta_table (`id` UInt64 CODEC(Delta(tuple()))) ENGINE = MergeTree ORDER BY tuple() SETTINGS index_granularity = 23962, min_bytes_for_wide_part = 1073741824, 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 = 0, compact_parts_max_bytes_to_buffer = 492481491, compact_parts_max_granules_to_buffer = 168, compact_parts_merge_max_bytes_to_prefetch_part = 10420064, merge_max_block_size = 24474, old_parts_lifetime = 480., 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 = 4380511, use_const_adaptive_granularity = true, enable_index_granularity_compression = true, concurrent_part_removal_threshold = 31, 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 = 34018, primary_key_compress_block_size = 27044, 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. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000000a074fcb 4. /build/src/Compression/CompressionCodecDelta.cpp:207: std::shared_ptr std::__function::__policy_invoker (std::shared_ptr const&, DB::IDataType const*)>::__call_impl[abi:se190107] (std::shared_ptr const&, DB::IDataType const*)>>(std::__function::__policy_storage const*, std::shared_ptr const&, DB::IDataType const*) @ 0x0000000017948988 5. /build/src/Compression/CompressionFactoryAdditions.cpp:135: void std::__function::__policy_invoker::__call_impl[abi:se190107] const&, std::shared_ptr const&, bool, bool, bool, bool) const::$_0, void (DB::ISerialization::SubstreamPath const&)>>(std::__function::__policy_storage const*, DB::ISerialization::SubstreamPath const&) @ 0x00000000179690ac 6. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000013c7aa09 7. /build/src/DataTypes/Serializations/ISerialization.cpp:104: DB::ISerialization::enumerateStreams(std::function const&, std::shared_ptr const&, COW::immutable_ptr const&) const @ 0x0000000013c7acfd 8. /build/src/Compression/CompressionFactoryAdditions.cpp:146: DB::CompressionCodecFactory::validateCodecAndGetPreprocessedAST(std::shared_ptr const&, std::shared_ptr const&, bool, bool, bool, bool) const @ 0x000000001796804d 9. /build/src/Interpreters/InterpreterCreateQuery.cpp:706: DB::InterpreterCreateQuery::getColumnsDescription(DB::ASTExpressionList const&, std::shared_ptr, DB::LoadingStrictnessLevel, bool) @ 0x00000000148ed211 10. /build/src/Interpreters/InterpreterCreateQuery.cpp:784: DB::InterpreterCreateQuery::getTablePropertiesAndNormalizeCreateQuery(DB::ASTCreateQuery&, DB::LoadingStrictnessLevel) const @ 0x00000000148ee1e4 11. /build/src/Interpreters/InterpreterCreateQuery.cpp:1657: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000148f901b 12. /build/src/Interpreters/InterpreterCreateQuery.cpp:2352: DB::InterpreterCreateQuery::execute() @ 0x0000000014905a41 13. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88dc9 14. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 15. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 16. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 17. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 18. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 19. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 20. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 21. ? @ 0x00007fbc6213eac3 22. ? @ 0x00007fbc621d0850 2025.07.28 12:02:11.728455 [ 5879 ] {} TCPHandler: Code: 433. DB::Exception: Delta codec argument must be unsigned integer. (ILLEGAL_CODEC_PARAMETER), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000000a074fcb 4. /build/src/Compression/CompressionCodecDelta.cpp:207: std::shared_ptr std::__function::__policy_invoker (std::shared_ptr const&, DB::IDataType const*)>::__call_impl[abi:se190107] (std::shared_ptr const&, DB::IDataType const*)>>(std::__function::__policy_storage const*, std::shared_ptr const&, DB::IDataType const*) @ 0x0000000017948988 5. /build/src/Compression/CompressionFactoryAdditions.cpp:135: void std::__function::__policy_invoker::__call_impl[abi:se190107] const&, std::shared_ptr const&, bool, bool, bool, bool) const::$_0, void (DB::ISerialization::SubstreamPath const&)>>(std::__function::__policy_storage const*, DB::ISerialization::SubstreamPath const&) @ 0x00000000179690ac 6. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000013c7aa09 7. /build/src/DataTypes/Serializations/ISerialization.cpp:104: DB::ISerialization::enumerateStreams(std::function const&, std::shared_ptr const&, COW::immutable_ptr const&) const @ 0x0000000013c7acfd 8. /build/src/Compression/CompressionFactoryAdditions.cpp:146: DB::CompressionCodecFactory::validateCodecAndGetPreprocessedAST(std::shared_ptr const&, std::shared_ptr const&, bool, bool, bool, bool) const @ 0x000000001796804d 9. /build/src/Interpreters/InterpreterCreateQuery.cpp:706: DB::InterpreterCreateQuery::getColumnsDescription(DB::ASTExpressionList const&, std::shared_ptr, DB::LoadingStrictnessLevel, bool) @ 0x00000000148ed211 10. /build/src/Interpreters/InterpreterCreateQuery.cpp:784: DB::InterpreterCreateQuery::getTablePropertiesAndNormalizeCreateQuery(DB::ASTCreateQuery&, DB::LoadingStrictnessLevel) const @ 0x00000000148ee1e4 11. /build/src/Interpreters/InterpreterCreateQuery.cpp:1657: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000148f901b 12. /build/src/Interpreters/InterpreterCreateQuery.cpp:2352: DB::InterpreterCreateQuery::execute() @ 0x0000000014905a41 13. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88dc9 14. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 15. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 16. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 17. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 18. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 19. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 20. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 21. ? @ 0x00007fbc6213eac3 22. ? @ 0x00007fbc621d0850 2025.07.28 12:02:11.784615 [ 3966 ] {} test_13.rmt2 (7f9b740d-015c-470e-8cc6-8ba33be0dc63): auto DB::StorageReplicatedMergeTree::processQueueEntry(ReplicatedMergeTreeQueue::SelectedEntryPtr)::(anonymous class)::operator()(LogEntryPtr &) const: Code: 86. DB::HTTPException: Received error from remote server http://146b4357c08d:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Ftest%2F01165%2Ftest_13%2Frmt%2Freplicas%2F1&part=20250728_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.6.10636.altinitytest (altinity build)) '. (RECEIVED_ERROR_FROM_REMOTE_IO_SERVER), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.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 const&, int&&, String const&, unsigned long&&, String const&) @ 0x000000000feda8d9 4. /build/src/IO/HTTPCommon.cpp:104: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x000000000feda6e2 5. /build/src/IO/HTTPCommon.cpp:93: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x000000000feda537 6. /build/src/IO/ReadWriteBufferFromHTTP.cpp:277: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x000000001184a4c4 7. /build/src/IO/ReadWriteBufferFromHTTP.cpp:285: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x000000001184a615 8. /build/src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x000000001184ae59 9. /build/src/IO/ReadWriteBufferFromHTTP.cpp:472: void std::__function::__policy_invoker::__call_impl[abi:se190107]>(std::__function::__policy_storage const*) @ 0x000000001184cedd 10. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001184858b 11. /build/src/IO/ReadWriteBufferFromHTTP.cpp:465: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x000000001184bf0b 12. /build/src/IO/ReadBuffer.h:60: DB::ReadBuffer::next() @ 0x000000000a148c7b 13. /build/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) @ 0x0000000011849fb2 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]>&)>&, 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&) @ 0x0000000011841980 15. /build/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) @ 0x000000001621208e 16. /build/src/Storages/StorageReplicatedMergeTree.cpp:5228: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl[abi:se190107] const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000015f9a5fe 17. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000015ed8bfd 18. /build/src/Storages/StorageReplicatedMergeTree.cpp:2514: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x0000000015ec9aab 19. /build/src/Storages/StorageReplicatedMergeTree.cpp:2349: DB::StorageReplicatedMergeTree::executeLogEntry(DB::ReplicatedMergeTreeLogEntry&) @ 0x0000000015eba91b 20. /build/src/Storages/StorageReplicatedMergeTree.cpp:3876: bool std::__function::__policy_invoker&)>::__call_impl[abi:se190107])::$_1, bool (std::shared_ptr&)>>(std::__function::__policy_storage const*, std::shared_ptr&) @ 0x0000000015f9837e 21. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000165d6fc3 22. /build/src/Storages/StorageReplicatedMergeTree.cpp:3872: DB::StorageReplicatedMergeTree::processQueueEntry(std::shared_ptr) @ 0x0000000015efc18a 23. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001624c1b2 24. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000162f9c70 25. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x00000000162fa55a 26. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc6653 27. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000000fccc4c3 28. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc3d92 29. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fcca080 30. ? @ 0x00007fbc6213eac3 31. ? @ 0x00007fbc621d0850 (version 25.3.6.10636.altinitytest (altinity build)) 2025.07.28 12:02:11.897894 [ 17255 ] {7fc75dd3-bca0-469a-95d8-7807899f889b} executeQuery: Code: 394. DB::Exception: Query was cancelled. (QUERY_WAS_CANCELLED) (version 25.3.6.10636.altinitytest (altinity build)) (from [::1]:43192) (comment: 02461_cancel_finish_race.sh) (query 1, line 1) (in query: KILL QUERY WHERE current_database = 'test_dtwle8fg' SYNC FORMAT Null), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000000a074fcb 4. /build/src/Interpreters/ProcessList.cpp:567: DB::QueryStatus::throwQueryWasCancelled() const @ 0x0000000014a4bc85 5. /build/src/Interpreters/ProcessList.cpp:520: DB::QueryStatus::throwProperExceptionIfNeeded(unsigned long const&, unsigned long const&) @ 0x0000000014a4bbd9 6. /build/src/Interpreters/ProcessList.cpp:531: DB::QueryStatus::addPipelineExecutor(DB::PipelineExecutor*) @ 0x0000000014a4bd9c 7. /build/src/Processors/Executors/PipelineExecutor.cpp:73: DB::PipelineExecutor::PipelineExecutor(std::shared_ptr, std::allocator>>>&, std::shared_ptr) @ 0x00000000169afe31 8. /build/contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x00000000169bef66 9. /build/src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x00000000169bf518 10. /build/src/Server/TCPHandler.cpp:1237: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x00000000168f1525 11. /build/src/Server/TCPHandler.cpp:678: DB::TCPHandler::runImpl() @ 0x00000000168e68e5 12. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 13. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 14. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 16. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 17. ? @ 0x00007fbc6213eac3 18. ? @ 0x00007fbc621d0850 2025.07.28 12:02:11.913122 [ 17255 ] {} TCPHandler: Code: 394. DB::Exception: Query was cancelled. (QUERY_WAS_CANCELLED), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000000a074fcb 4. /build/src/Interpreters/ProcessList.cpp:567: DB::QueryStatus::throwQueryWasCancelled() const @ 0x0000000014a4bc85 5. /build/src/Interpreters/ProcessList.cpp:520: DB::QueryStatus::throwProperExceptionIfNeeded(unsigned long const&, unsigned long const&) @ 0x0000000014a4bbd9 6. /build/src/Interpreters/ProcessList.cpp:531: DB::QueryStatus::addPipelineExecutor(DB::PipelineExecutor*) @ 0x0000000014a4bd9c 7. /build/src/Processors/Executors/PipelineExecutor.cpp:73: DB::PipelineExecutor::PipelineExecutor(std::shared_ptr, std::allocator>>>&, std::shared_ptr) @ 0x00000000169afe31 8. /build/contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x00000000169bef66 9. /build/src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x00000000169bf518 10. /build/src/Server/TCPHandler.cpp:1237: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x00000000168f1525 11. /build/src/Server/TCPHandler.cpp:678: DB::TCPHandler::runImpl() @ 0x00000000168e68e5 12. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 13. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 14. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 16. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 17. ? @ 0x00007fbc6213eac3 18. ? @ 0x00007fbc621d0850 2025.07.28 12:02:11.915992 [ 62058 ] {c4a97aa0-3b3c-4ec2-ac3c-30c6e0423024} executeQuery: Code: 394. DB::Exception: Query was cancelled. (QUERY_WAS_CANCELLED) (version 25.3.6.10636.altinitytest (altinity build)) (from [::1]:43220) (comment: 02461_cancel_finish_race.sh) (query 1, line 1) (in query: KILL QUERY WHERE current_database = 'test_dtwle8fg' SYNC FORMAT Null), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000000a074fcb 4. /build/src/Interpreters/ProcessList.cpp:567: DB::QueryStatus::throwQueryWasCancelled() const @ 0x0000000014a4bc85 5. /build/src/Interpreters/ProcessList.cpp:520: DB::QueryStatus::throwProperExceptionIfNeeded(unsigned long const&, unsigned long const&) @ 0x0000000014a4bbd9 6. /build/src/Interpreters/ProcessList.cpp:531: DB::QueryStatus::addPipelineExecutor(DB::PipelineExecutor*) @ 0x0000000014a4bd9c 7. /build/src/Processors/Executors/PipelineExecutor.cpp:73: DB::PipelineExecutor::PipelineExecutor(std::shared_ptr, std::allocator>>>&, std::shared_ptr) @ 0x00000000169afe31 8. /build/contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x00000000169bef66 9. /build/src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x00000000169bf518 10. /build/src/Server/TCPHandler.cpp:1237: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x00000000168f1525 11. /build/src/Server/TCPHandler.cpp:678: DB::TCPHandler::runImpl() @ 0x00000000168e68e5 12. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 13. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 14. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 16. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 17. ? @ 0x00007fbc6213eac3 18. ? @ 0x00007fbc621d0850 2025.07.28 12:02:11.916136 [ 17203 ] {daba086e-a86c-4386-b3e8-41a82de9ff7e} executeQuery: Code: 394. DB::Exception: Query was cancelled. (QUERY_WAS_CANCELLED) (version 25.3.6.10636.altinitytest (altinity build)) (from [::1]:43204) (comment: 02461_cancel_finish_race.sh) (query 1, line 1) (in query: KILL QUERY WHERE current_database = 'test_dtwle8fg' SYNC FORMAT Null), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000000a074fcb 4. /build/src/Interpreters/ProcessList.cpp:567: DB::QueryStatus::throwQueryWasCancelled() const @ 0x0000000014a4bc85 5. /build/src/Interpreters/ProcessList.cpp:520: DB::QueryStatus::throwProperExceptionIfNeeded(unsigned long const&, unsigned long const&) @ 0x0000000014a4bbd9 6. /build/src/Interpreters/ProcessList.cpp:531: DB::QueryStatus::addPipelineExecutor(DB::PipelineExecutor*) @ 0x0000000014a4bd9c 7. /build/src/Processors/Executors/PipelineExecutor.cpp:73: DB::PipelineExecutor::PipelineExecutor(std::shared_ptr, std::allocator>>>&, std::shared_ptr) @ 0x00000000169afe31 8. /build/contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x00000000169bef66 9. /build/src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x00000000169bf518 10. /build/src/Server/TCPHandler.cpp:1237: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x00000000168f1525 11. /build/src/Server/TCPHandler.cpp:678: DB::TCPHandler::runImpl() @ 0x00000000168e68e5 12. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 13. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 14. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 16. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 17. ? @ 0x00007fbc6213eac3 18. ? @ 0x00007fbc621d0850 2025.07.28 12:02:11.933633 [ 17203 ] {} TCPHandler: Code: 394. DB::Exception: Query was cancelled. (QUERY_WAS_CANCELLED), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000000a074fcb 4. /build/src/Interpreters/ProcessList.cpp:567: DB::QueryStatus::throwQueryWasCancelled() const @ 0x0000000014a4bc85 5. /build/src/Interpreters/ProcessList.cpp:520: DB::QueryStatus::throwProperExceptionIfNeeded(unsigned long const&, unsigned long const&) @ 0x0000000014a4bbd9 6. /build/src/Interpreters/ProcessList.cpp:531: DB::QueryStatus::addPipelineExecutor(DB::PipelineExecutor*) @ 0x0000000014a4bd9c 7. /build/src/Processors/Executors/PipelineExecutor.cpp:73: DB::PipelineExecutor::PipelineExecutor(std::shared_ptr, std::allocator>>>&, std::shared_ptr) @ 0x00000000169afe31 8. /build/contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x00000000169bef66 9. /build/src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x00000000169bf518 10. /build/src/Server/TCPHandler.cpp:1237: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x00000000168f1525 11. /build/src/Server/TCPHandler.cpp:678: DB::TCPHandler::runImpl() @ 0x00000000168e68e5 12. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 13. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 14. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 16. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 17. ? @ 0x00007fbc6213eac3 18. ? @ 0x00007fbc621d0850 2025.07.28 12:02:11.964822 [ 5879 ] {8a60b053-78fe-4e06-91d8-e17d738b3c07} executeQuery: Code: 433. DB::Exception: ZSTD codec argument must be integer. (ILLEGAL_CODEC_PARAMETER) (version 25.3.6.10636.altinitytest (altinity build)) (from [::1]:43074) (comment: 01296_codecs_bad_arguments.sql) (query 5, line 6) (in query: CREATE TABLE zstd_table (`id` UInt64 CODEC(ZSTD(tuple()))) ENGINE = MergeTree ORDER BY tuple() SETTINGS index_granularity = 23962, min_bytes_for_wide_part = 1073741824, 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 = 0, compact_parts_max_bytes_to_buffer = 492481491, compact_parts_max_granules_to_buffer = 168, compact_parts_merge_max_bytes_to_prefetch_part = 10420064, merge_max_block_size = 24474, old_parts_lifetime = 480., 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 = 4380511, use_const_adaptive_granularity = true, enable_index_granularity_compression = true, concurrent_part_removal_threshold = 31, 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 = 34018, primary_key_compress_block_size = 27044, 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. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000000a074fcb 4. /build/src/Compression/CompressionCodecZSTD.cpp:99: std::shared_ptr std::__function::__policy_invoker (std::shared_ptr const&)>::__call_impl[abi:se190107] (std::shared_ptr const&)>>(std::__function::__policy_storage const*, std::shared_ptr const&) @ 0x0000000017944732 5. /build/src/Compression/CompressionFactoryAdditions.cpp:135: void std::__function::__policy_invoker::__call_impl[abi:se190107] const&, std::shared_ptr const&, bool, bool, bool, bool) const::$_0, void (DB::ISerialization::SubstreamPath const&)>>(std::__function::__policy_storage const*, DB::ISerialization::SubstreamPath const&) @ 0x00000000179690ac 6. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000013c7aa09 7. /build/src/DataTypes/Serializations/ISerialization.cpp:104: DB::ISerialization::enumerateStreams(std::function const&, std::shared_ptr const&, COW::immutable_ptr const&) const @ 0x0000000013c7acfd 8. /build/src/Compression/CompressionFactoryAdditions.cpp:146: DB::CompressionCodecFactory::validateCodecAndGetPreprocessedAST(std::shared_ptr const&, std::shared_ptr const&, bool, bool, bool, bool) const @ 0x000000001796804d 9. /build/src/Interpreters/InterpreterCreateQuery.cpp:706: DB::InterpreterCreateQuery::getColumnsDescription(DB::ASTExpressionList const&, std::shared_ptr, DB::LoadingStrictnessLevel, bool) @ 0x00000000148ed211 10. /build/src/Interpreters/InterpreterCreateQuery.cpp:784: DB::InterpreterCreateQuery::getTablePropertiesAndNormalizeCreateQuery(DB::ASTCreateQuery&, DB::LoadingStrictnessLevel) const @ 0x00000000148ee1e4 11. /build/src/Interpreters/InterpreterCreateQuery.cpp:1657: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000148f901b 12. /build/src/Interpreters/InterpreterCreateQuery.cpp:2352: DB::InterpreterCreateQuery::execute() @ 0x0000000014905a41 13. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88dc9 14. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 15. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 16. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 17. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 18. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 19. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 20. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 21. ? @ 0x00007fbc6213eac3 22. ? @ 0x00007fbc621d0850 2025.07.28 12:02:11.966853 [ 17256 ] {bfca61a9-a3a5-4f03-8001-98eadf12d3a4} executeQuery: Code: 394. DB::Exception: Query was cancelled. (QUERY_WAS_CANCELLED) (version 25.3.6.10636.altinitytest (altinity build)) (from [::1]:43194) (comment: 02461_cancel_finish_race.sh) (query 1, line 1) (in query: KILL QUERY WHERE current_database = 'test_dtwle8fg' SYNC FORMAT Null), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000000a074fcb 4. /build/src/Interpreters/ProcessList.cpp:567: DB::QueryStatus::throwQueryWasCancelled() const @ 0x0000000014a4bc85 5. /build/src/Interpreters/ProcessList.cpp:520: DB::QueryStatus::throwProperExceptionIfNeeded(unsigned long const&, unsigned long const&) @ 0x0000000014a4bbd9 6. /build/src/Interpreters/ProcessList.cpp:557: DB::QueryStatus::checkTimeLimit() @ 0x0000000014a4c2cd 7. /build/src/Processors/Executors/PipelineExecutor.cpp:206: DB::PipelineExecutor::finalizeExecution() @ 0x00000000169b13ba 8. /build/src/Processors/Executors/PipelineExecutor.cpp:153: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x00000000169b0584 9. /build/src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:se190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169bfeab 10. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc3d92 11. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fcca080 12. ? @ 0x00007fbc6213eac3 13. ? @ 0x00007fbc621d0850 2025.07.28 12:02:11.973793 [ 3961 ] {} test_13.rmt2 (7f9b740d-015c-470e-8cc6-8ba33be0dc63): auto DB::StorageReplicatedMergeTree::processQueueEntry(ReplicatedMergeTreeQueue::SelectedEntryPtr)::(anonymous class)::operator()(LogEntryPtr &) const: Code: 86. DB::HTTPException: Received error from remote server http://146b4357c08d:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Ftest%2F01165%2Ftest_13%2Frmt%2Freplicas%2F1&part=20250728_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.6.10636.altinitytest (altinity build)) '. (RECEIVED_ERROR_FROM_REMOTE_IO_SERVER), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.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 const&, int&&, String const&, unsigned long&&, String const&) @ 0x000000000feda8d9 4. /build/src/IO/HTTPCommon.cpp:104: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x000000000feda6e2 5. /build/src/IO/HTTPCommon.cpp:93: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x000000000feda537 6. /build/src/IO/ReadWriteBufferFromHTTP.cpp:277: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x000000001184a4c4 7. /build/src/IO/ReadWriteBufferFromHTTP.cpp:285: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x000000001184a615 8. /build/src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x000000001184ae59 9. /build/src/IO/ReadWriteBufferFromHTTP.cpp:472: void std::__function::__policy_invoker::__call_impl[abi:se190107]>(std::__function::__policy_storage const*) @ 0x000000001184cedd 10. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001184858b 11. /build/src/IO/ReadWriteBufferFromHTTP.cpp:465: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x000000001184bf0b 12. /build/src/IO/ReadBuffer.h:60: DB::ReadBuffer::next() @ 0x000000000a148c7b 13. /build/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) @ 0x0000000011849fb2 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]>&)>&, 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&) @ 0x0000000011841980 15. /build/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) @ 0x000000001621208e 16. /build/src/Storages/StorageReplicatedMergeTree.cpp:5228: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl[abi:se190107] const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000015f9a5fe 17. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000015ed8bfd 18. /build/src/Storages/StorageReplicatedMergeTree.cpp:2514: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x0000000015ec9aab 19. /build/src/Storages/StorageReplicatedMergeTree.cpp:2349: DB::StorageReplicatedMergeTree::executeLogEntry(DB::ReplicatedMergeTreeLogEntry&) @ 0x0000000015eba91b 20. /build/src/Storages/StorageReplicatedMergeTree.cpp:3876: bool std::__function::__policy_invoker&)>::__call_impl[abi:se190107])::$_1, bool (std::shared_ptr&)>>(std::__function::__policy_storage const*, std::shared_ptr&) @ 0x0000000015f9837e 21. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000165d6fc3 22. /build/src/Storages/StorageReplicatedMergeTree.cpp:3872: DB::StorageReplicatedMergeTree::processQueueEntry(std::shared_ptr) @ 0x0000000015efc18a 23. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001624c1b2 24. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000162f9c70 25. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x00000000162fa55a 26. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc6653 27. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000000fccc4c3 28. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc3d92 29. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fcca080 30. ? @ 0x00007fbc6213eac3 31. ? @ 0x00007fbc621d0850 (version 25.3.6.10636.altinitytest (altinity build)) 2025.07.28 12:02:11.980037 [ 62058 ] {} TCPHandler: Code: 394. DB::Exception: Query was cancelled. (QUERY_WAS_CANCELLED), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000000a074fcb 4. /build/src/Interpreters/ProcessList.cpp:567: DB::QueryStatus::throwQueryWasCancelled() const @ 0x0000000014a4bc85 5. /build/src/Interpreters/ProcessList.cpp:520: DB::QueryStatus::throwProperExceptionIfNeeded(unsigned long const&, unsigned long const&) @ 0x0000000014a4bbd9 6. /build/src/Interpreters/ProcessList.cpp:531: DB::QueryStatus::addPipelineExecutor(DB::PipelineExecutor*) @ 0x0000000014a4bd9c 7. /build/src/Processors/Executors/PipelineExecutor.cpp:73: DB::PipelineExecutor::PipelineExecutor(std::shared_ptr, std::allocator>>>&, std::shared_ptr) @ 0x00000000169afe31 8. /build/contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x00000000169bef66 9. /build/src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x00000000169bf518 10. /build/src/Server/TCPHandler.cpp:1237: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x00000000168f1525 11. /build/src/Server/TCPHandler.cpp:678: DB::TCPHandler::runImpl() @ 0x00000000168e68e5 12. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 13. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 14. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 16. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 17. ? @ 0x00007fbc6213eac3 18. ? @ 0x00007fbc621d0850 2025.07.28 12:02:12.003602 [ 17256 ] {} TCPHandler: Code: 394. DB::Exception: Query was cancelled. (QUERY_WAS_CANCELLED), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000000a074fcb 4. /build/src/Interpreters/ProcessList.cpp:567: DB::QueryStatus::throwQueryWasCancelled() const @ 0x0000000014a4bc85 5. /build/src/Interpreters/ProcessList.cpp:520: DB::QueryStatus::throwProperExceptionIfNeeded(unsigned long const&, unsigned long const&) @ 0x0000000014a4bbd9 6. /build/src/Interpreters/ProcessList.cpp:557: DB::QueryStatus::checkTimeLimit() @ 0x0000000014a4c2cd 7. /build/src/Processors/Executors/PipelineExecutor.cpp:206: DB::PipelineExecutor::finalizeExecution() @ 0x00000000169b13ba 8. /build/src/Processors/Executors/PipelineExecutor.cpp:153: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x00000000169b0584 9. /build/src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:se190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169bfeab 10. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc3d92 11. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fcca080 12. ? @ 0x00007fbc6213eac3 13. ? @ 0x00007fbc621d0850 Job's origin stack trace: 0. /build/src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000000fc33b84 1. /build/src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000000fcc2ea7 2. /build/src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fcc535c 3. /build/src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000000fcc584d 4. /build/src/Common/ThreadPool.h:279: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x00000000169bf193 5. /build/src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x00000000169bf518 6. /build/src/Server/TCPHandler.cpp:1237: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x00000000168f1525 7. /build/src/Server/TCPHandler.cpp:678: DB::TCPHandler::runImpl() @ 0x00000000168e68e5 8. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 9. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 10. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 11. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 12. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 13. ? @ 0x00007fbc6213eac3 14. ? @ 0x00007fbc621d0850 2025.07.28 12:02:12.015784 [ 5879 ] {} TCPHandler: Code: 433. DB::Exception: ZSTD codec argument must be integer. (ILLEGAL_CODEC_PARAMETER), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000000a074fcb 4. /build/src/Compression/CompressionCodecZSTD.cpp:99: std::shared_ptr std::__function::__policy_invoker (std::shared_ptr const&)>::__call_impl[abi:se190107] (std::shared_ptr const&)>>(std::__function::__policy_storage const*, std::shared_ptr const&) @ 0x0000000017944732 5. /build/src/Compression/CompressionFactoryAdditions.cpp:135: void std::__function::__policy_invoker::__call_impl[abi:se190107] const&, std::shared_ptr const&, bool, bool, bool, bool) const::$_0, void (DB::ISerialization::SubstreamPath const&)>>(std::__function::__policy_storage const*, DB::ISerialization::SubstreamPath const&) @ 0x00000000179690ac 6. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000013c7aa09 7. /build/src/DataTypes/Serializations/ISerialization.cpp:104: DB::ISerialization::enumerateStreams(std::function const&, std::shared_ptr const&, COW::immutable_ptr const&) const @ 0x0000000013c7acfd 8. /build/src/Compression/CompressionFactoryAdditions.cpp:146: DB::CompressionCodecFactory::validateCodecAndGetPreprocessedAST(std::shared_ptr const&, std::shared_ptr const&, bool, bool, bool, bool) const @ 0x000000001796804d 9. /build/src/Interpreters/InterpreterCreateQuery.cpp:706: DB::InterpreterCreateQuery::getColumnsDescription(DB::ASTExpressionList const&, std::shared_ptr, DB::LoadingStrictnessLevel, bool) @ 0x00000000148ed211 10. /build/src/Interpreters/InterpreterCreateQuery.cpp:784: DB::InterpreterCreateQuery::getTablePropertiesAndNormalizeCreateQuery(DB::ASTCreateQuery&, DB::LoadingStrictnessLevel) const @ 0x00000000148ee1e4 11. /build/src/Interpreters/InterpreterCreateQuery.cpp:1657: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000148f901b 12. /build/src/Interpreters/InterpreterCreateQuery.cpp:2352: DB::InterpreterCreateQuery::execute() @ 0x0000000014905a41 13. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88dc9 14. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 15. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 16. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 17. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 18. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 19. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 20. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 21. ? @ 0x00007fbc6213eac3 22. ? @ 0x00007fbc621d0850 2025.07.28 12:02:12.063744 [ 62056 ] {baceafc7-5770-4686-a711-536043613f87} executeQuery: Code: 394. DB::Exception: Query was cancelled. (QUERY_WAS_CANCELLED) (version 25.3.6.10636.altinitytest (altinity build)) (from [::1]:42904) (comment: 02461_cancel_finish_race.sh) (query 1, line 1) (in query: KILL QUERY WHERE current_database = 'test_dtwle8fg' SYNC FORMAT Null), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000000a074fcb 4. /build/src/Interpreters/ProcessList.cpp:567: DB::QueryStatus::throwQueryWasCancelled() const @ 0x0000000014a4bc85 5. /build/src/Interpreters/ProcessList.cpp:520: DB::QueryStatus::throwProperExceptionIfNeeded(unsigned long const&, unsigned long const&) @ 0x0000000014a4bbd9 6. /build/src/Interpreters/ProcessList.cpp:557: DB::QueryStatus::checkTimeLimit() @ 0x0000000014a4c2cd 7. /build/src/Processors/Executors/PipelineExecutor.cpp:206: DB::PipelineExecutor::finalizeExecution() @ 0x00000000169b13ba 8. /build/src/Processors/Executors/PipelineExecutor.cpp:153: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x00000000169b0584 9. /build/src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:se190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169bfeab 10. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc3d92 11. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fcca080 12. ? @ 0x00007fbc6213eac3 13. ? @ 0x00007fbc621d0850 2025.07.28 12:02:12.068472 [ 62056 ] {} TCPHandler: Code: 394. DB::Exception: Query was cancelled. (QUERY_WAS_CANCELLED), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000000a074fcb 4. /build/src/Interpreters/ProcessList.cpp:567: DB::QueryStatus::throwQueryWasCancelled() const @ 0x0000000014a4bc85 5. /build/src/Interpreters/ProcessList.cpp:520: DB::QueryStatus::throwProperExceptionIfNeeded(unsigned long const&, unsigned long const&) @ 0x0000000014a4bbd9 6. /build/src/Interpreters/ProcessList.cpp:557: DB::QueryStatus::checkTimeLimit() @ 0x0000000014a4c2cd 7. /build/src/Processors/Executors/PipelineExecutor.cpp:206: DB::PipelineExecutor::finalizeExecution() @ 0x00000000169b13ba 8. /build/src/Processors/Executors/PipelineExecutor.cpp:153: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x00000000169b0584 9. /build/src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:se190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169bfeab 10. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc3d92 11. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fcca080 12. ? @ 0x00007fbc6213eac3 13. ? @ 0x00007fbc621d0850 Job's origin stack trace: 0. /build/src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000000fc33b84 1. /build/src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000000fcc2ea7 2. /build/src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fcc535c 3. /build/src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000000fcc584d 4. /build/src/Common/ThreadPool.h:279: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x00000000169bf193 5. /build/src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x00000000169bf518 6. /build/src/Server/TCPHandler.cpp:1237: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x00000000168f1525 7. /build/src/Server/TCPHandler.cpp:678: DB::TCPHandler::runImpl() @ 0x00000000168e68e5 8. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 9. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 10. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 11. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 12. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 13. ? @ 0x00007fbc6213eac3 14. ? @ 0x00007fbc621d0850 2025.07.28 12:02:12.094472 [ 62314 ] {efe47d20-4148-4542-8cb1-b41f7e6bc142} executeQuery: Code: 394. DB::Exception: Query was cancelled. (QUERY_WAS_CANCELLED) (version 25.3.6.10636.altinitytest (altinity build)) (from [::1]:42952) (comment: 02461_cancel_finish_race.sh) (query 1, line 1) (in query: KILL QUERY WHERE current_database = 'test_dtwle8fg' SYNC FORMAT Null), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000000a074fcb 4. /build/src/Interpreters/ProcessList.cpp:567: DB::QueryStatus::throwQueryWasCancelled() const @ 0x0000000014a4bc85 5. /build/src/Interpreters/ProcessList.cpp:520: DB::QueryStatus::throwProperExceptionIfNeeded(unsigned long const&, unsigned long const&) @ 0x0000000014a4bbd9 6. /build/src/Interpreters/ProcessList.cpp:557: DB::QueryStatus::checkTimeLimit() @ 0x0000000014a4c2cd 7. /build/src/Processors/Executors/PipelineExecutor.cpp:206: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x00000000169b03a3 8. /build/src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:se190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169bfeab 9. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc3d92 10. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fcca080 11. ? @ 0x00007fbc6213eac3 12. ? @ 0x00007fbc621d0850 2025.07.28 12:02:12.095478 [ 62103 ] {} TCPHandler: Code: 394. DB::Exception: Query was cancelled. (QUERY_WAS_CANCELLED), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000000a074fcb 4. /build/src/Interpreters/ProcessList.cpp:567: DB::QueryStatus::throwQueryWasCancelled() const @ 0x0000000014a4bc85 5. /build/src/Interpreters/ProcessList.cpp:520: DB::QueryStatus::throwProperExceptionIfNeeded(unsigned long const&, unsigned long const&) @ 0x0000000014a4bbd9 6. /build/src/Interpreters/ProcessList.cpp:557: DB::QueryStatus::checkTimeLimit() @ 0x0000000014a4c2cd 7. /build/src/Processors/Executors/PipelineExecutor.cpp:206: DB::PipelineExecutor::finalizeExecution() @ 0x00000000169b13ba 8. /build/src/Processors/Executors/PipelineExecutor.cpp:181: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x00000000169b1726 9. /build/src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x00000000169c081c 10. /build/src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x00000000169c0978 11. /build/src/Interpreters/InterpreterKillQueryQuery.cpp:439: DB::InterpreterKillQueryQuery::getSelectResult(String const&, String const&) @ 0x0000000014cf0f04 12. /build/src/Interpreters/InterpreterKillQueryQuery.cpp:222: DB::InterpreterKillQueryQuery::execute() @ 0x0000000014cebde2 13. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88dc9 14. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 15. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 16. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 17. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 18. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 19. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 20. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 21. ? @ 0x00007fbc6213eac3 22. ? @ 0x00007fbc621d0850 2025.07.28 12:02:12.120314 [ 62314 ] {} TCPHandler: Code: 394. DB::Exception: Query was cancelled. (QUERY_WAS_CANCELLED), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000000a074fcb 4. /build/src/Interpreters/ProcessList.cpp:567: DB::QueryStatus::throwQueryWasCancelled() const @ 0x0000000014a4bc85 5. /build/src/Interpreters/ProcessList.cpp:520: DB::QueryStatus::throwProperExceptionIfNeeded(unsigned long const&, unsigned long const&) @ 0x0000000014a4bbd9 6. /build/src/Interpreters/ProcessList.cpp:557: DB::QueryStatus::checkTimeLimit() @ 0x0000000014a4c2cd 7. /build/src/Processors/Executors/PipelineExecutor.cpp:206: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x00000000169b03a3 8. /build/src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:se190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169bfeab 9. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc3d92 10. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fcca080 11. ? @ 0x00007fbc6213eac3 12. ? @ 0x00007fbc621d0850 Job's origin stack trace: 0. /build/src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000000fc33b84 1. /build/src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000000fcc2ea7 2. /build/src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fcc535c 3. /build/src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000000fcc584d 4. /build/src/Common/ThreadPool.h:279: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x00000000169bf193 5. /build/src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x00000000169bf518 6. /build/src/Server/TCPHandler.cpp:1237: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x00000000168f1525 7. /build/src/Server/TCPHandler.cpp:678: DB::TCPHandler::runImpl() @ 0x00000000168e68e5 8. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 9. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 10. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 11. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 12. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 13. ? @ 0x00007fbc6213eac3 14. ? @ 0x00007fbc621d0850 2025.07.28 12:02:12.147023 [ 3974 ] {} test_13.rmt2 (7f9b740d-015c-470e-8cc6-8ba33be0dc63): auto DB::StorageReplicatedMergeTree::processQueueEntry(ReplicatedMergeTreeQueue::SelectedEntryPtr)::(anonymous class)::operator()(LogEntryPtr &) const: Code: 86. DB::HTTPException: Received error from remote server http://146b4357c08d:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Ftest%2F01165%2Ftest_13%2Frmt%2Freplicas%2F1&part=20250728_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.6.10636.altinitytest (altinity build)) '. (RECEIVED_ERROR_FROM_REMOTE_IO_SERVER), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.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 const&, int&&, String const&, unsigned long&&, String const&) @ 0x000000000feda8d9 4. /build/src/IO/HTTPCommon.cpp:104: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x000000000feda6e2 5. /build/src/IO/HTTPCommon.cpp:93: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x000000000feda537 6. /build/src/IO/ReadWriteBufferFromHTTP.cpp:277: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x000000001184a4c4 7. /build/src/IO/ReadWriteBufferFromHTTP.cpp:285: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x000000001184a615 8. /build/src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x000000001184ae59 9. /build/src/IO/ReadWriteBufferFromHTTP.cpp:472: void std::__function::__policy_invoker::__call_impl[abi:se190107]>(std::__function::__policy_storage const*) @ 0x000000001184cedd 10. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001184858b 11. /build/src/IO/ReadWriteBufferFromHTTP.cpp:465: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x000000001184bf0b 12. /build/src/IO/ReadBuffer.h:60: DB::ReadBuffer::next() @ 0x000000000a148c7b 13. /build/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) @ 0x0000000011849fb2 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]>&)>&, 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&) @ 0x0000000011841980 15. /build/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) @ 0x000000001621208e 16. /build/src/Storages/StorageReplicatedMergeTree.cpp:5228: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl[abi:se190107] const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000015f9a5fe 17. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000015ed8bfd 18. /build/src/Storages/StorageReplicatedMergeTree.cpp:2514: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x0000000015ec9aab 19. /build/src/Storages/StorageReplicatedMergeTree.cpp:2349: DB::StorageReplicatedMergeTree::executeLogEntry(DB::ReplicatedMergeTreeLogEntry&) @ 0x0000000015eba91b 20. /build/src/Storages/StorageReplicatedMergeTree.cpp:3876: bool std::__function::__policy_invoker&)>::__call_impl[abi:se190107])::$_1, bool (std::shared_ptr&)>>(std::__function::__policy_storage const*, std::shared_ptr&) @ 0x0000000015f9837e 21. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000165d6fc3 22. /build/src/Storages/StorageReplicatedMergeTree.cpp:3872: DB::StorageReplicatedMergeTree::processQueueEntry(std::shared_ptr) @ 0x0000000015efc18a 23. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001624c1b2 24. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000162f9c70 25. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x00000000162fa55a 26. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc6653 27. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000000fccc4c3 28. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc3d92 29. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fcca080 30. ? @ 0x00007fbc6213eac3 31. ? @ 0x00007fbc621d0850 (version 25.3.6.10636.altinitytest (altinity build)) 2025.07.28 12:02:12.262329 [ 5879 ] {09a1da7c-5f40-4fbb-888e-c49ead174e6d} executeQuery: Code: 433. DB::Exception: LZ4HC codec argument must be integer. (ILLEGAL_CODEC_PARAMETER) (version 25.3.6.10636.altinitytest (altinity build)) (from [::1]:43074) (comment: 01296_codecs_bad_arguments.sql) (query 6, line 7) (in query: CREATE TABLE lz4_table (`id` UInt64 CODEC(LZ4HC(tuple()))) ENGINE = MergeTree ORDER BY tuple() SETTINGS index_granularity = 23962, min_bytes_for_wide_part = 1073741824, 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 = 0, compact_parts_max_bytes_to_buffer = 492481491, compact_parts_max_granules_to_buffer = 168, compact_parts_merge_max_bytes_to_prefetch_part = 10420064, merge_max_block_size = 24474, old_parts_lifetime = 480., 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 = 4380511, use_const_adaptive_granularity = true, enable_index_granularity_compression = true, concurrent_part_removal_threshold = 31, 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 = 34018, primary_key_compress_block_size = 27044, 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. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000000a074fcb 4. /build/src/Compression/CompressionCodecLZ4.cpp:134: std::shared_ptr std::__function::__policy_invoker (std::shared_ptr const&)>::__call_impl[abi:se190107] (std::shared_ptr const&)>>(std::__function::__policy_storage const*, std::shared_ptr const&) @ 0x00000000179437b1 5. /build/src/Compression/CompressionFactoryAdditions.cpp:135: void std::__function::__policy_invoker::__call_impl[abi:se190107] const&, std::shared_ptr const&, bool, bool, bool, bool) const::$_0, void (DB::ISerialization::SubstreamPath const&)>>(std::__function::__policy_storage const*, DB::ISerialization::SubstreamPath const&) @ 0x00000000179690ac 6. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000013c7aa09 7. /build/src/DataTypes/Serializations/ISerialization.cpp:104: DB::ISerialization::enumerateStreams(std::function const&, std::shared_ptr const&, COW::immutable_ptr const&) const @ 0x0000000013c7acfd 8. /build/src/Compression/CompressionFactoryAdditions.cpp:146: DB::CompressionCodecFactory::validateCodecAndGetPreprocessedAST(std::shared_ptr const&, std::shared_ptr const&, bool, bool, bool, bool) const @ 0x000000001796804d 9. /build/src/Interpreters/InterpreterCreateQuery.cpp:706: DB::InterpreterCreateQuery::getColumnsDescription(DB::ASTExpressionList const&, std::shared_ptr, DB::LoadingStrictnessLevel, bool) @ 0x00000000148ed211 10. /build/src/Interpreters/InterpreterCreateQuery.cpp:784: DB::InterpreterCreateQuery::getTablePropertiesAndNormalizeCreateQuery(DB::ASTCreateQuery&, DB::LoadingStrictnessLevel) const @ 0x00000000148ee1e4 11. /build/src/Interpreters/InterpreterCreateQuery.cpp:1657: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000148f901b 12. /build/src/Interpreters/InterpreterCreateQuery.cpp:2352: DB::InterpreterCreateQuery::execute() @ 0x0000000014905a41 13. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88dc9 14. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 15. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 16. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 17. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 18. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 19. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 20. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 21. ? @ 0x00007fbc6213eac3 22. ? @ 0x00007fbc621d0850 2025.07.28 12:02:12.287149 [ 5879 ] {} TCPHandler: Code: 433. DB::Exception: LZ4HC codec argument must be integer. (ILLEGAL_CODEC_PARAMETER), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000000a074fcb 4. /build/src/Compression/CompressionCodecLZ4.cpp:134: std::shared_ptr std::__function::__policy_invoker (std::shared_ptr const&)>::__call_impl[abi:se190107] (std::shared_ptr const&)>>(std::__function::__policy_storage const*, std::shared_ptr const&) @ 0x00000000179437b1 5. /build/src/Compression/CompressionFactoryAdditions.cpp:135: void std::__function::__policy_invoker::__call_impl[abi:se190107] const&, std::shared_ptr const&, bool, bool, bool, bool) const::$_0, void (DB::ISerialization::SubstreamPath const&)>>(std::__function::__policy_storage const*, DB::ISerialization::SubstreamPath const&) @ 0x00000000179690ac 6. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000013c7aa09 7. /build/src/DataTypes/Serializations/ISerialization.cpp:104: DB::ISerialization::enumerateStreams(std::function const&, std::shared_ptr const&, COW::immutable_ptr const&) const @ 0x0000000013c7acfd 8. /build/src/Compression/CompressionFactoryAdditions.cpp:146: DB::CompressionCodecFactory::validateCodecAndGetPreprocessedAST(std::shared_ptr const&, std::shared_ptr const&, bool, bool, bool, bool) const @ 0x000000001796804d 9. /build/src/Interpreters/InterpreterCreateQuery.cpp:706: DB::InterpreterCreateQuery::getColumnsDescription(DB::ASTExpressionList const&, std::shared_ptr, DB::LoadingStrictnessLevel, bool) @ 0x00000000148ed211 10. /build/src/Interpreters/InterpreterCreateQuery.cpp:784: DB::InterpreterCreateQuery::getTablePropertiesAndNormalizeCreateQuery(DB::ASTCreateQuery&, DB::LoadingStrictnessLevel) const @ 0x00000000148ee1e4 11. /build/src/Interpreters/InterpreterCreateQuery.cpp:1657: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000148f901b 12. /build/src/Interpreters/InterpreterCreateQuery.cpp:2352: DB::InterpreterCreateQuery::execute() @ 0x0000000014905a41 13. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88dc9 14. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 15. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 16. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 17. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 18. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 19. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 20. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 21. ? @ 0x00007fbc6213eac3 22. ? @ 0x00007fbc621d0850 2025.07.28 12:02:12.407852 [ 5879 ] {34a55014-b0f1-4d4a-896d-e006b152e948} executeQuery: Code: 378. DB::Exception: Compression codec LZ4 cannot have arguments. (DATA_TYPE_CANNOT_HAVE_ARGUMENTS) (version 25.3.6.10636.altinitytest (altinity build)) (from [::1]:43074) (comment: 01296_codecs_bad_arguments.sql) (query 7, line 9) (in query: CREATE TABLE lz4_table (`id` UInt64 CODEC(LZ4(tuple()))) ENGINE = MergeTree ORDER BY tuple() SETTINGS index_granularity = 23962, min_bytes_for_wide_part = 1073741824, 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 = 0, compact_parts_max_bytes_to_buffer = 492481491, compact_parts_max_granules_to_buffer = 168, compact_parts_merge_max_bytes_to_prefetch_part = 10420064, merge_max_block_size = 24474, old_parts_lifetime = 480., 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 = 4380511, use_const_adaptive_granularity = true, enable_index_granularity_compression = true, concurrent_part_removal_threshold = 31, 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 = 34018, primary_key_compress_block_size = 27044, 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. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000a9b78ab 4. /build/src/Compression/CompressionFactory.cpp:164: std::shared_ptr std::__function::__policy_invoker (std::shared_ptr const&)>::__call_impl[abi:se190107], std::function ()>)::$_0, std::shared_ptr (std::shared_ptr const&)>>(std::__function::__policy_storage const*, std::shared_ptr const&) @ 0x00000000179409b8 5. /build/src/Compression/CompressionFactoryAdditions.cpp:135: void std::__function::__policy_invoker::__call_impl[abi:se190107] const&, std::shared_ptr const&, bool, bool, bool, bool) const::$_0, void (DB::ISerialization::SubstreamPath const&)>>(std::__function::__policy_storage const*, DB::ISerialization::SubstreamPath const&) @ 0x00000000179690ac 6. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000013c7aa09 7. /build/src/DataTypes/Serializations/ISerialization.cpp:104: DB::ISerialization::enumerateStreams(std::function const&, std::shared_ptr const&, COW::immutable_ptr const&) const @ 0x0000000013c7acfd 8. /build/src/Compression/CompressionFactoryAdditions.cpp:146: DB::CompressionCodecFactory::validateCodecAndGetPreprocessedAST(std::shared_ptr const&, std::shared_ptr const&, bool, bool, bool, bool) const @ 0x000000001796804d 9. /build/src/Interpreters/InterpreterCreateQuery.cpp:706: DB::InterpreterCreateQuery::getColumnsDescription(DB::ASTExpressionList const&, std::shared_ptr, DB::LoadingStrictnessLevel, bool) @ 0x00000000148ed211 10. /build/src/Interpreters/InterpreterCreateQuery.cpp:784: DB::InterpreterCreateQuery::getTablePropertiesAndNormalizeCreateQuery(DB::ASTCreateQuery&, DB::LoadingStrictnessLevel) const @ 0x00000000148ee1e4 11. /build/src/Interpreters/InterpreterCreateQuery.cpp:1657: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000148f901b 12. /build/src/Interpreters/InterpreterCreateQuery.cpp:2352: DB::InterpreterCreateQuery::execute() @ 0x0000000014905a41 13. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88dc9 14. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 15. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 16. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 17. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 18. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 19. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 20. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 21. ? @ 0x00007fbc6213eac3 22. ? @ 0x00007fbc621d0850 2025.07.28 12:02:12.419761 [ 4446 ] {9275140f-0297-46a8-b860-4adef3e465d0} executeQuery: Code: 394. DB::Exception: Query was cancelled. (QUERY_WAS_CANCELLED) (version 25.3.6.10636.altinitytest (altinity build)) (from [::1]:42964) (comment: 02461_cancel_finish_race.sh) (query 1, line 1) (in query: KILL QUERY WHERE current_database = 'test_dtwle8fg' SYNC FORMAT Null), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000000a074fcb 4. /build/src/Interpreters/ProcessList.cpp:567: DB::QueryStatus::throwQueryWasCancelled() const @ 0x0000000014a4bc85 5. /build/src/Interpreters/ProcessList.cpp:520: DB::QueryStatus::throwProperExceptionIfNeeded(unsigned long const&, unsigned long const&) @ 0x0000000014a4bbd9 6. /build/src/Interpreters/ProcessList.cpp:557: DB::QueryStatus::checkTimeLimit() @ 0x0000000014a4c2cd 7. /build/src/Processors/Executors/PipelineExecutor.cpp:206: DB::PipelineExecutor::finalizeExecution() @ 0x00000000169b13ba 8. /build/src/Processors/Executors/PipelineExecutor.cpp:153: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x00000000169b0584 9. /build/src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:se190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169bfeab 10. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc3d92 11. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fcca080 12. ? @ 0x00007fbc6213eac3 13. ? @ 0x00007fbc621d0850 2025.07.28 12:02:12.427479 [ 5879 ] {} TCPHandler: Code: 378. DB::Exception: Compression codec LZ4 cannot have arguments. (DATA_TYPE_CANNOT_HAVE_ARGUMENTS), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000a9b78ab 4. /build/src/Compression/CompressionFactory.cpp:164: std::shared_ptr std::__function::__policy_invoker (std::shared_ptr const&)>::__call_impl[abi:se190107], std::function ()>)::$_0, std::shared_ptr (std::shared_ptr const&)>>(std::__function::__policy_storage const*, std::shared_ptr const&) @ 0x00000000179409b8 5. /build/src/Compression/CompressionFactoryAdditions.cpp:135: void std::__function::__policy_invoker::__call_impl[abi:se190107] const&, std::shared_ptr const&, bool, bool, bool, bool) const::$_0, void (DB::ISerialization::SubstreamPath const&)>>(std::__function::__policy_storage const*, DB::ISerialization::SubstreamPath const&) @ 0x00000000179690ac 6. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000013c7aa09 7. /build/src/DataTypes/Serializations/ISerialization.cpp:104: DB::ISerialization::enumerateStreams(std::function const&, std::shared_ptr const&, COW::immutable_ptr const&) const @ 0x0000000013c7acfd 8. /build/src/Compression/CompressionFactoryAdditions.cpp:146: DB::CompressionCodecFactory::validateCodecAndGetPreprocessedAST(std::shared_ptr const&, std::shared_ptr const&, bool, bool, bool, bool) const @ 0x000000001796804d 9. /build/src/Interpreters/InterpreterCreateQuery.cpp:706: DB::InterpreterCreateQuery::getColumnsDescription(DB::ASTExpressionList const&, std::shared_ptr, DB::LoadingStrictnessLevel, bool) @ 0x00000000148ed211 10. /build/src/Interpreters/InterpreterCreateQuery.cpp:784: DB::InterpreterCreateQuery::getTablePropertiesAndNormalizeCreateQuery(DB::ASTCreateQuery&, DB::LoadingStrictnessLevel) const @ 0x00000000148ee1e4 11. /build/src/Interpreters/InterpreterCreateQuery.cpp:1657: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000148f901b 12. /build/src/Interpreters/InterpreterCreateQuery.cpp:2352: DB::InterpreterCreateQuery::execute() @ 0x0000000014905a41 13. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88dc9 14. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 15. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 16. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 17. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 18. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 19. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 20. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 21. ? @ 0x00007fbc6213eac3 22. ? @ 0x00007fbc621d0850 2025.07.28 12:02:12.430913 [ 4446 ] {} TCPHandler: Code: 394. DB::Exception: Query was cancelled. (QUERY_WAS_CANCELLED), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000000a074fcb 4. /build/src/Interpreters/ProcessList.cpp:567: DB::QueryStatus::throwQueryWasCancelled() const @ 0x0000000014a4bc85 5. /build/src/Interpreters/ProcessList.cpp:520: DB::QueryStatus::throwProperExceptionIfNeeded(unsigned long const&, unsigned long const&) @ 0x0000000014a4bbd9 6. /build/src/Interpreters/ProcessList.cpp:557: DB::QueryStatus::checkTimeLimit() @ 0x0000000014a4c2cd 7. /build/src/Processors/Executors/PipelineExecutor.cpp:206: DB::PipelineExecutor::finalizeExecution() @ 0x00000000169b13ba 8. /build/src/Processors/Executors/PipelineExecutor.cpp:153: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x00000000169b0584 9. /build/src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:se190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169bfeab 10. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc3d92 11. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fcca080 12. ? @ 0x00007fbc6213eac3 13. ? @ 0x00007fbc621d0850 Job's origin stack trace: 0. /build/src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000000fc33b84 1. /build/src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000000fcc2ea7 2. /build/src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fcc535c 3. /build/src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000000fcc584d 4. /build/src/Common/ThreadPool.h:279: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x00000000169bf193 5. /build/src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x00000000169bf518 6. /build/src/Server/TCPHandler.cpp:1237: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x00000000168f1525 7. /build/src/Server/TCPHandler.cpp:678: DB::TCPHandler::runImpl() @ 0x00000000168e68e5 8. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 9. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 10. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 11. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 12. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 13. ? @ 0x00007fbc6213eac3 14. ? @ 0x00007fbc621d0850 2025.07.28 12:02:12.433690 [ 4900 ] {913ad78c-b80d-4da5-b851-fac3a1dfb5a6} executeQuery: Code: 394. DB::Exception: Query was cancelled. (QUERY_WAS_CANCELLED) (version 25.3.6.10636.altinitytest (altinity build)) (from [::1]:43030) (comment: 02461_cancel_finish_race.sh) (query 1, line 1) (in query: KILL QUERY WHERE current_database = 'test_dtwle8fg' SYNC FORMAT Null), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000000a074fcb 4. /build/src/Interpreters/ProcessList.cpp:567: DB::QueryStatus::throwQueryWasCancelled() const @ 0x0000000014a4bc85 5. /build/src/Interpreters/ProcessList.cpp:520: DB::QueryStatus::throwProperExceptionIfNeeded(unsigned long const&, unsigned long const&) @ 0x0000000014a4bbd9 6. /build/src/Interpreters/ProcessList.cpp:557: DB::QueryStatus::checkTimeLimit() @ 0x0000000014a4c2cd 7. /build/src/Processors/Executors/PipelineExecutor.cpp:206: DB::PipelineExecutor::finalizeExecution() @ 0x00000000169b13ba 8. /build/src/Processors/Executors/PipelineExecutor.cpp:153: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x00000000169b0584 9. /build/src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:se190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169bfeab 10. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc3d92 11. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fcca080 12. ? @ 0x00007fbc6213eac3 13. ? @ 0x00007fbc621d0850 2025.07.28 12:02:12.434673 [ 62093 ] {feb9433d-d303-4df4-8fd6-cc888c9e2913} executeQuery: Code: 394. DB::Exception: Query was cancelled. (QUERY_WAS_CANCELLED) (version 25.3.6.10636.altinitytest (altinity build)) (from [::1]:42998) (comment: 02461_cancel_finish_race.sh) (query 1, line 1) (in query: KILL QUERY WHERE current_database = 'test_dtwle8fg' SYNC FORMAT Null), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000000a074fcb 4. /build/src/Interpreters/ProcessList.cpp:567: DB::QueryStatus::throwQueryWasCancelled() const @ 0x0000000014a4bc85 5. /build/src/Interpreters/ProcessList.cpp:520: DB::QueryStatus::throwProperExceptionIfNeeded(unsigned long const&, unsigned long const&) @ 0x0000000014a4bbd9 6. /build/src/Interpreters/ProcessList.cpp:557: DB::QueryStatus::checkTimeLimit() @ 0x0000000014a4c2cd 7. /build/src/Processors/Executors/PipelineExecutor.cpp:206: DB::PipelineExecutor::finalizeExecution() @ 0x00000000169b13ba 8. /build/src/Processors/Executors/PipelineExecutor.cpp:153: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x00000000169b0584 9. /build/src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:se190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169bfeab 10. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc3d92 11. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fcca080 12. ? @ 0x00007fbc6213eac3 13. ? @ 0x00007fbc621d0850 2025.07.28 12:02:12.450484 [ 4900 ] {} TCPHandler: Code: 394. DB::Exception: Query was cancelled. (QUERY_WAS_CANCELLED), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000000a074fcb 4. /build/src/Interpreters/ProcessList.cpp:567: DB::QueryStatus::throwQueryWasCancelled() const @ 0x0000000014a4bc85 5. /build/src/Interpreters/ProcessList.cpp:520: DB::QueryStatus::throwProperExceptionIfNeeded(unsigned long const&, unsigned long const&) @ 0x0000000014a4bbd9 6. /build/src/Interpreters/ProcessList.cpp:557: DB::QueryStatus::checkTimeLimit() @ 0x0000000014a4c2cd 7. /build/src/Processors/Executors/PipelineExecutor.cpp:206: DB::PipelineExecutor::finalizeExecution() @ 0x00000000169b13ba 8. /build/src/Processors/Executors/PipelineExecutor.cpp:153: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x00000000169b0584 9. /build/src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:se190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169bfeab 10. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc3d92 11. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fcca080 12. ? @ 0x00007fbc6213eac3 13. ? @ 0x00007fbc621d0850 Job's origin stack trace: 0. /build/src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000000fc33b84 1. /build/src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000000fcc2ea7 2. /build/src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fcc535c 3. /build/src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000000fcc584d 4. /build/src/Common/ThreadPool.h:279: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x00000000169bf193 5. /build/src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x00000000169bf518 6. /build/src/Server/TCPHandler.cpp:1237: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x00000000168f1525 7. /build/src/Server/TCPHandler.cpp:678: DB::TCPHandler::runImpl() @ 0x00000000168e68e5 8. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 9. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 10. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 11. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 12. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 13. ? @ 0x00007fbc6213eac3 14. ? @ 0x00007fbc621d0850 2025.07.28 12:02:12.450537 [ 62093 ] {} TCPHandler: Code: 394. DB::Exception: Query was cancelled. (QUERY_WAS_CANCELLED), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000000a074fcb 4. /build/src/Interpreters/ProcessList.cpp:567: DB::QueryStatus::throwQueryWasCancelled() const @ 0x0000000014a4bc85 5. /build/src/Interpreters/ProcessList.cpp:520: DB::QueryStatus::throwProperExceptionIfNeeded(unsigned long const&, unsigned long const&) @ 0x0000000014a4bbd9 6. /build/src/Interpreters/ProcessList.cpp:557: DB::QueryStatus::checkTimeLimit() @ 0x0000000014a4c2cd 7. /build/src/Processors/Executors/PipelineExecutor.cpp:206: DB::PipelineExecutor::finalizeExecution() @ 0x00000000169b13ba 8. /build/src/Processors/Executors/PipelineExecutor.cpp:153: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x00000000169b0584 9. /build/src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:se190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169bfeab 10. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc3d92 11. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fcca080 12. ? @ 0x00007fbc6213eac3 13. ? @ 0x00007fbc621d0850 Job's origin stack trace: 0. /build/src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000000fc33b84 1. /build/src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000000fcc2ea7 2. /build/src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fcc535c 3. /build/src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000000fcc584d 4. /build/src/Common/ThreadPool.h:279: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x00000000169bf193 5. /build/src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x00000000169bf518 6. /build/src/Server/TCPHandler.cpp:1237: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x00000000168f1525 7. /build/src/Server/TCPHandler.cpp:678: DB::TCPHandler::runImpl() @ 0x00000000168e68e5 8. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 9. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 10. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 11. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 12. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 13. ? @ 0x00007fbc6213eac3 14. ? @ 0x00007fbc621d0850 2025.07.28 12:02:12.598322 [ 62114 ] {e50c7a4c-1398-4532-b3ed-6c56b8b19b70} executeQuery: Code: 394. DB::Exception: Query was cancelled. (QUERY_WAS_CANCELLED) (version 25.3.6.10636.altinitytest (altinity build)) (from [::1]:43136) (comment: 02461_cancel_finish_race.sh) (query 1, line 1) (in query: KILL QUERY WHERE current_database = 'test_dtwle8fg' SYNC FORMAT Null), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000000a074fcb 4. /build/src/Interpreters/ProcessList.cpp:567: DB::QueryStatus::throwQueryWasCancelled() const @ 0x0000000014a4bc85 5. /build/src/Interpreters/ProcessList.cpp:520: DB::QueryStatus::throwProperExceptionIfNeeded(unsigned long const&, unsigned long const&) @ 0x0000000014a4bbd9 6. /build/src/Interpreters/ProcessList.cpp:531: DB::QueryStatus::addPipelineExecutor(DB::PipelineExecutor*) @ 0x0000000014a4bd9c 7. /build/src/Processors/Executors/PipelineExecutor.cpp:73: DB::PipelineExecutor::PipelineExecutor(std::shared_ptr, std::allocator>>>&, std::shared_ptr) @ 0x00000000169afe31 8. /build/contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x00000000169bef66 9. /build/src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x00000000169bf518 10. /build/src/Server/TCPHandler.cpp:1237: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x00000000168f1525 11. /build/src/Server/TCPHandler.cpp:678: DB::TCPHandler::runImpl() @ 0x00000000168e68e5 12. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 13. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 14. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 16. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 17. ? @ 0x00007fbc6213eac3 18. ? @ 0x00007fbc621d0850 2025.07.28 12:02:12.638220 [ 62114 ] {} TCPHandler: Code: 394. DB::Exception: Query was cancelled. (QUERY_WAS_CANCELLED), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000000a074fcb 4. /build/src/Interpreters/ProcessList.cpp:567: DB::QueryStatus::throwQueryWasCancelled() const @ 0x0000000014a4bc85 5. /build/src/Interpreters/ProcessList.cpp:520: DB::QueryStatus::throwProperExceptionIfNeeded(unsigned long const&, unsigned long const&) @ 0x0000000014a4bbd9 6. /build/src/Interpreters/ProcessList.cpp:531: DB::QueryStatus::addPipelineExecutor(DB::PipelineExecutor*) @ 0x0000000014a4bd9c 7. /build/src/Processors/Executors/PipelineExecutor.cpp:73: DB::PipelineExecutor::PipelineExecutor(std::shared_ptr, std::allocator>>>&, std::shared_ptr) @ 0x00000000169afe31 8. /build/contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x00000000169bef66 9. /build/src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x00000000169bf518 10. /build/src/Server/TCPHandler.cpp:1237: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x00000000168f1525 11. /build/src/Server/TCPHandler.cpp:678: DB::TCPHandler::runImpl() @ 0x00000000168e68e5 12. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 13. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 14. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 16. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 17. ? @ 0x00007fbc6213eac3 18. ? @ 0x00007fbc621d0850 2025.07.28 12:02:12.655011 [ 3960 ] {} test_13.rmt2 (7f9b740d-015c-470e-8cc6-8ba33be0dc63): auto DB::StorageReplicatedMergeTree::processQueueEntry(ReplicatedMergeTreeQueue::SelectedEntryPtr)::(anonymous class)::operator()(LogEntryPtr &) const: Code: 86. DB::HTTPException: Received error from remote server http://146b4357c08d:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Ftest%2F01165%2Ftest_13%2Frmt%2Freplicas%2F1&part=20250728_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.6.10636.altinitytest (altinity build)) '. (RECEIVED_ERROR_FROM_REMOTE_IO_SERVER), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.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 const&, int&&, String const&, unsigned long&&, String const&) @ 0x000000000feda8d9 4. /build/src/IO/HTTPCommon.cpp:104: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x000000000feda6e2 5. /build/src/IO/HTTPCommon.cpp:93: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x000000000feda537 6. /build/src/IO/ReadWriteBufferFromHTTP.cpp:277: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x000000001184a4c4 7. /build/src/IO/ReadWriteBufferFromHTTP.cpp:285: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x000000001184a615 8. /build/src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x000000001184ae59 9. /build/src/IO/ReadWriteBufferFromHTTP.cpp:472: void std::__function::__policy_invoker::__call_impl[abi:se190107]>(std::__function::__policy_storage const*) @ 0x000000001184cedd 10. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001184858b 11. /build/src/IO/ReadWriteBufferFromHTTP.cpp:465: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x000000001184bf0b 12. /build/src/IO/ReadBuffer.h:60: DB::ReadBuffer::next() @ 0x000000000a148c7b 13. /build/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) @ 0x0000000011849fb2 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]>&)>&, 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&) @ 0x0000000011841980 15. /build/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) @ 0x000000001621208e 16. /build/src/Storages/StorageReplicatedMergeTree.cpp:5228: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl[abi:se190107] const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000015f9a5fe 17. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000015ed8bfd 18. /build/src/Storages/StorageReplicatedMergeTree.cpp:2514: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x0000000015ec9aab 19. /build/src/Storages/StorageReplicatedMergeTree.cpp:2349: DB::StorageReplicatedMergeTree::executeLogEntry(DB::ReplicatedMergeTreeLogEntry&) @ 0x0000000015eba91b 20. /build/src/Storages/StorageReplicatedMergeTree.cpp:3876: bool std::__function::__policy_invoker&)>::__call_impl[abi:se190107])::$_1, bool (std::shared_ptr&)>>(std::__function::__policy_storage const*, std::shared_ptr&) @ 0x0000000015f9837e 21. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000165d6fc3 22. /build/src/Storages/StorageReplicatedMergeTree.cpp:3872: DB::StorageReplicatedMergeTree::processQueueEntry(std::shared_ptr) @ 0x0000000015efc18a 23. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001624c1b2 24. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000162f9c70 25. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x00000000162fa55a 26. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc6653 27. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000000fccc4c3 28. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc3d92 29. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fcca080 30. ? @ 0x00007fbc6213eac3 31. ? @ 0x00007fbc621d0850 (version 25.3.6.10636.altinitytest (altinity build)) 2025.07.28 12:02:12.819860 [ 62075 ] {b056563a-9ef0-43b9-a2c0-4cde6909c130} executeQuery: Code: 394. DB::Exception: Query was cancelled. (QUERY_WAS_CANCELLED) (version 25.3.6.10636.altinitytest (altinity build)) (from [::1]:43190) (comment: 02461_cancel_finish_race.sh) (query 1, line 1) (in query: KILL QUERY WHERE current_database = 'test_dtwle8fg' SYNC FORMAT Null), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000000a074fcb 4. /build/src/Interpreters/ProcessList.cpp:567: DB::QueryStatus::throwQueryWasCancelled() const @ 0x0000000014a4bc85 5. /build/src/Interpreters/ProcessList.cpp:520: DB::QueryStatus::throwProperExceptionIfNeeded(unsigned long const&, unsigned long const&) @ 0x0000000014a4bbd9 6. /build/src/Interpreters/ProcessList.cpp:531: DB::QueryStatus::addPipelineExecutor(DB::PipelineExecutor*) @ 0x0000000014a4bd9c 7. /build/src/Processors/Executors/PipelineExecutor.cpp:73: DB::PipelineExecutor::PipelineExecutor(std::shared_ptr, std::allocator>>>&, std::shared_ptr) @ 0x00000000169afe31 8. /build/contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x00000000169bef66 9. /build/src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x00000000169bf518 10. /build/src/Server/TCPHandler.cpp:1237: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x00000000168f1525 11. /build/src/Server/TCPHandler.cpp:678: DB::TCPHandler::runImpl() @ 0x00000000168e68e5 12. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 13. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 14. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 16. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 17. ? @ 0x00007fbc6213eac3 18. ? @ 0x00007fbc621d0850 2025.07.28 12:02:12.830091 [ 17252 ] {} TCPHandler: Code: 394. DB::Exception: Query was cancelled. (QUERY_WAS_CANCELLED), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000000a074fcb 4. /build/src/Interpreters/ProcessList.cpp:567: DB::QueryStatus::throwQueryWasCancelled() const @ 0x0000000014a4bc85 5. /build/src/Interpreters/ProcessList.cpp:520: DB::QueryStatus::throwProperExceptionIfNeeded(unsigned long const&, unsigned long const&) @ 0x0000000014a4bbd9 6. /build/src/Interpreters/ProcessList.cpp:557: DB::QueryStatus::checkTimeLimit() @ 0x0000000014a4c2cd 7. /build/src/Processors/Executors/PipelineExecutor.cpp:206: DB::PipelineExecutor::finalizeExecution() @ 0x00000000169b13ba 8. /build/src/Processors/Executors/PipelineExecutor.cpp:181: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x00000000169b1726 9. /build/src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x00000000169c081c 10. /build/src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x00000000169c0978 11. /build/src/Interpreters/InterpreterKillQueryQuery.cpp:439: DB::InterpreterKillQueryQuery::getSelectResult(String const&, String const&) @ 0x0000000014cf0f04 12. /build/src/Interpreters/InterpreterKillQueryQuery.cpp:222: DB::InterpreterKillQueryQuery::execute() @ 0x0000000014cebde2 13. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88dc9 14. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 15. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 16. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 17. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 18. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 19. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 20. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 21. ? @ 0x00007fbc6213eac3 22. ? @ 0x00007fbc621d0850 2025.07.28 12:02:12.831819 [ 62053 ] {} TCPHandler: Code: 394. DB::Exception: Query 'af3ef1b2-1356-4ad2-8afa-186858ce6127' is killed in pending state. (QUERY_WAS_CANCELLED), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x000000000a06b56b 4. /build/src/Interpreters/executeQuery.cpp:1522: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c8a4ef 5. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 6. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 7. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 8. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 9. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 10. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 11. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 12. ? @ 0x00007fbc6213eac3 13. ? @ 0x00007fbc621d0850 2025.07.28 12:02:12.857593 [ 62075 ] {} TCPHandler: Code: 394. DB::Exception: Query was cancelled. (QUERY_WAS_CANCELLED), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000000a074fcb 4. /build/src/Interpreters/ProcessList.cpp:567: DB::QueryStatus::throwQueryWasCancelled() const @ 0x0000000014a4bc85 5. /build/src/Interpreters/ProcessList.cpp:520: DB::QueryStatus::throwProperExceptionIfNeeded(unsigned long const&, unsigned long const&) @ 0x0000000014a4bbd9 6. /build/src/Interpreters/ProcessList.cpp:531: DB::QueryStatus::addPipelineExecutor(DB::PipelineExecutor*) @ 0x0000000014a4bd9c 7. /build/src/Processors/Executors/PipelineExecutor.cpp:73: DB::PipelineExecutor::PipelineExecutor(std::shared_ptr, std::allocator>>>&, std::shared_ptr) @ 0x00000000169afe31 8. /build/contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x00000000169bef66 9. /build/src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x00000000169bf518 10. /build/src/Server/TCPHandler.cpp:1237: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x00000000168f1525 11. /build/src/Server/TCPHandler.cpp:678: DB::TCPHandler::runImpl() @ 0x00000000168e68e5 12. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 13. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 14. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 16. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 17. ? @ 0x00007fbc6213eac3 18. ? @ 0x00007fbc621d0850 2025.07.28 12:02:12.869108 [ 3977 ] {} test_13.rmt2 (7f9b740d-015c-470e-8cc6-8ba33be0dc63): auto DB::StorageReplicatedMergeTree::processQueueEntry(ReplicatedMergeTreeQueue::SelectedEntryPtr)::(anonymous class)::operator()(LogEntryPtr &) const: Code: 86. DB::HTTPException: Received error from remote server http://146b4357c08d:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Ftest%2F01165%2Ftest_13%2Frmt%2Freplicas%2F1&part=20250728_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.6.10636.altinitytest (altinity build)) '. (RECEIVED_ERROR_FROM_REMOTE_IO_SERVER), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.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 const&, int&&, String const&, unsigned long&&, String const&) @ 0x000000000feda8d9 4. /build/src/IO/HTTPCommon.cpp:104: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x000000000feda6e2 5. /build/src/IO/HTTPCommon.cpp:93: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x000000000feda537 6. /build/src/IO/ReadWriteBufferFromHTTP.cpp:277: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x000000001184a4c4 7. /build/src/IO/ReadWriteBufferFromHTTP.cpp:285: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x000000001184a615 8. /build/src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x000000001184ae59 9. /build/src/IO/ReadWriteBufferFromHTTP.cpp:472: void std::__function::__policy_invoker::__call_impl[abi:se190107]>(std::__function::__policy_storage const*) @ 0x000000001184cedd 10. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001184858b 11. /build/src/IO/ReadWriteBufferFromHTTP.cpp:465: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x000000001184bf0b 12. /build/src/IO/ReadBuffer.h:60: DB::ReadBuffer::next() @ 0x000000000a148c7b 13. /build/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) @ 0x0000000011849fb2 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]>&)>&, 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&) @ 0x0000000011841980 15. /build/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) @ 0x000000001621208e 16. /build/src/Storages/StorageReplicatedMergeTree.cpp:5228: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl[abi:se190107] const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000015f9a5fe 17. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000015ed8bfd 18. /build/src/Storages/StorageReplicatedMergeTree.cpp:2514: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x0000000015ec9aab 19. /build/src/Storages/StorageReplicatedMergeTree.cpp:2349: DB::StorageReplicatedMergeTree::executeLogEntry(DB::ReplicatedMergeTreeLogEntry&) @ 0x0000000015eba91b 20. /build/src/Storages/StorageReplicatedMergeTree.cpp:3876: bool std::__function::__policy_invoker&)>::__call_impl[abi:se190107])::$_1, bool (std::shared_ptr&)>>(std::__function::__policy_storage const*, std::shared_ptr&) @ 0x0000000015f9837e 21. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000165d6fc3 22. /build/src/Storages/StorageReplicatedMergeTree.cpp:3872: DB::StorageReplicatedMergeTree::processQueueEntry(std::shared_ptr) @ 0x0000000015efc18a 23. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001624c1b2 24. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000162f9c70 25. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x00000000162fa55a 26. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc6653 27. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000000fccc4c3 28. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc3d92 29. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fcca080 30. ? @ 0x00007fbc6213eac3 31. ? @ 0x00007fbc621d0850 (version 25.3.6.10636.altinitytest (altinity build)) 2025.07.28 12:02:13.072260 [ 62065 ] {f76fc549-7013-432b-a50b-b43a29484608} executeQuery: Code: 394. DB::Exception: Query was cancelled. (QUERY_WAS_CANCELLED) (version 25.3.6.10636.altinitytest (altinity build)) (from [::1]:43282) (comment: 02461_cancel_finish_race.sh) (query 1, line 1) (in query: KILL QUERY WHERE current_database = 'test_dtwle8fg' SYNC FORMAT Null), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000000a074fcb 4. /build/src/Interpreters/ProcessList.cpp:567: DB::QueryStatus::throwQueryWasCancelled() const @ 0x0000000014a4bc85 5. /build/src/Interpreters/ProcessList.cpp:520: DB::QueryStatus::throwProperExceptionIfNeeded(unsigned long const&, unsigned long const&) @ 0x0000000014a4bbd9 6. /build/src/Interpreters/ProcessList.cpp:531: DB::QueryStatus::addPipelineExecutor(DB::PipelineExecutor*) @ 0x0000000014a4bd9c 7. /build/src/Processors/Executors/PipelineExecutor.cpp:73: DB::PipelineExecutor::PipelineExecutor(std::shared_ptr, std::allocator>>>&, std::shared_ptr) @ 0x00000000169afe31 8. /build/contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x00000000169bef66 9. /build/src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x00000000169bf518 10. /build/src/Server/TCPHandler.cpp:1237: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x00000000168f1525 11. /build/src/Server/TCPHandler.cpp:678: DB::TCPHandler::runImpl() @ 0x00000000168e68e5 12. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 13. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 14. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 16. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 17. ? @ 0x00007fbc6213eac3 18. ? @ 0x00007fbc621d0850 2025.07.28 12:02:13.074207 [ 62325 ] {282134dc-9b66-4887-ae79-cd010d5c2849} executeQuery: Code: 394. DB::Exception: Query was cancelled. (QUERY_WAS_CANCELLED) (version 25.3.6.10636.altinitytest (altinity build)) (from [::1]:43280) (comment: 02461_cancel_finish_race.sh) (query 1, line 1) (in query: KILL QUERY WHERE current_database = 'test_dtwle8fg' SYNC FORMAT Null), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000000a074fcb 4. /build/src/Interpreters/ProcessList.cpp:567: DB::QueryStatus::throwQueryWasCancelled() const @ 0x0000000014a4bc85 5. /build/src/Interpreters/ProcessList.cpp:520: DB::QueryStatus::throwProperExceptionIfNeeded(unsigned long const&, unsigned long const&) @ 0x0000000014a4bbd9 6. /build/src/Interpreters/ProcessList.cpp:531: DB::QueryStatus::addPipelineExecutor(DB::PipelineExecutor*) @ 0x0000000014a4bd9c 7. /build/src/Processors/Executors/PipelineExecutor.cpp:73: DB::PipelineExecutor::PipelineExecutor(std::shared_ptr, std::allocator>>>&, std::shared_ptr) @ 0x00000000169afe31 8. /build/contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x00000000169bef66 9. /build/src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x00000000169bf518 10. /build/src/Server/TCPHandler.cpp:1237: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x00000000168f1525 11. /build/src/Server/TCPHandler.cpp:678: DB::TCPHandler::runImpl() @ 0x00000000168e68e5 12. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 13. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 14. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 16. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 17. ? @ 0x00007fbc6213eac3 18. ? @ 0x00007fbc621d0850 2025.07.28 12:02:13.085368 [ 62065 ] {} TCPHandler: Code: 394. DB::Exception: Query was cancelled. (QUERY_WAS_CANCELLED), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000000a074fcb 4. /build/src/Interpreters/ProcessList.cpp:567: DB::QueryStatus::throwQueryWasCancelled() const @ 0x0000000014a4bc85 5. /build/src/Interpreters/ProcessList.cpp:520: DB::QueryStatus::throwProperExceptionIfNeeded(unsigned long const&, unsigned long const&) @ 0x0000000014a4bbd9 6. /build/src/Interpreters/ProcessList.cpp:531: DB::QueryStatus::addPipelineExecutor(DB::PipelineExecutor*) @ 0x0000000014a4bd9c 7. /build/src/Processors/Executors/PipelineExecutor.cpp:73: DB::PipelineExecutor::PipelineExecutor(std::shared_ptr, std::allocator>>>&, std::shared_ptr) @ 0x00000000169afe31 8. /build/contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x00000000169bef66 9. /build/src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x00000000169bf518 10. /build/src/Server/TCPHandler.cpp:1237: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x00000000168f1525 11. /build/src/Server/TCPHandler.cpp:678: DB::TCPHandler::runImpl() @ 0x00000000168e68e5 12. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 13. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 14. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 16. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 17. ? @ 0x00007fbc6213eac3 18. ? @ 0x00007fbc621d0850 2025.07.28 12:02:13.110850 [ 62325 ] {} TCPHandler: Code: 394. DB::Exception: Query was cancelled. (QUERY_WAS_CANCELLED), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000000a074fcb 4. /build/src/Interpreters/ProcessList.cpp:567: DB::QueryStatus::throwQueryWasCancelled() const @ 0x0000000014a4bc85 5. /build/src/Interpreters/ProcessList.cpp:520: DB::QueryStatus::throwProperExceptionIfNeeded(unsigned long const&, unsigned long const&) @ 0x0000000014a4bbd9 6. /build/src/Interpreters/ProcessList.cpp:531: DB::QueryStatus::addPipelineExecutor(DB::PipelineExecutor*) @ 0x0000000014a4bd9c 7. /build/src/Processors/Executors/PipelineExecutor.cpp:73: DB::PipelineExecutor::PipelineExecutor(std::shared_ptr, std::allocator>>>&, std::shared_ptr) @ 0x00000000169afe31 8. /build/contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x00000000169bef66 9. /build/src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x00000000169bf518 10. /build/src/Server/TCPHandler.cpp:1237: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x00000000168f1525 11. /build/src/Server/TCPHandler.cpp:678: DB::TCPHandler::runImpl() @ 0x00000000168e68e5 12. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 13. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 14. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 16. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 17. ? @ 0x00007fbc6213eac3 18. ? @ 0x00007fbc621d0850 2025.07.28 12:02:13.119022 [ 17232 ] {} TCPHandler: Code: 394. DB::Exception: Query was cancelled. (QUERY_WAS_CANCELLED), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000000a074fcb 4. /build/src/Interpreters/ProcessList.cpp:567: DB::QueryStatus::throwQueryWasCancelled() const @ 0x0000000014a4bc85 5. /build/src/Interpreters/ProcessList.cpp:520: DB::QueryStatus::throwProperExceptionIfNeeded(unsigned long const&, unsigned long const&) @ 0x0000000014a4bbd9 6. /build/src/Interpreters/ProcessList.cpp:531: DB::QueryStatus::addPipelineExecutor(DB::PipelineExecutor*) @ 0x0000000014a4bd9c 7. /build/src/Processors/Executors/PipelineExecutor.cpp:73: DB::PipelineExecutor::PipelineExecutor(std::shared_ptr, std::allocator>>>&, std::shared_ptr) @ 0x00000000169afe31 8. /build/contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x00000000169c07b5 9. /build/src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x00000000169c0978 10. /build/src/Interpreters/InterpreterKillQueryQuery.cpp:439: DB::InterpreterKillQueryQuery::getSelectResult(String const&, String const&) @ 0x0000000014cf0f04 11. /build/src/Interpreters/InterpreterKillQueryQuery.cpp:222: DB::InterpreterKillQueryQuery::execute() @ 0x0000000014cebde2 12. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88dc9 13. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 14. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 15. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 16. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 17. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 18. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 19. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 20. ? @ 0x00007fbc6213eac3 21. ? @ 0x00007fbc621d0850 2025.07.28 12:02:13.206350 [ 3969 ] {} test_13.rmt2 (7f9b740d-015c-470e-8cc6-8ba33be0dc63): auto DB::StorageReplicatedMergeTree::processQueueEntry(ReplicatedMergeTreeQueue::SelectedEntryPtr)::(anonymous class)::operator()(LogEntryPtr &) const: Code: 86. DB::HTTPException: Received error from remote server http://146b4357c08d:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Ftest%2F01165%2Ftest_13%2Frmt%2Freplicas%2F1&part=20250728_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.6.10636.altinitytest (altinity build)) '. (RECEIVED_ERROR_FROM_REMOTE_IO_SERVER), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.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 const&, int&&, String const&, unsigned long&&, String const&) @ 0x000000000feda8d9 4. /build/src/IO/HTTPCommon.cpp:104: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x000000000feda6e2 5. /build/src/IO/HTTPCommon.cpp:93: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x000000000feda537 6. /build/src/IO/ReadWriteBufferFromHTTP.cpp:277: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x000000001184a4c4 7. /build/src/IO/ReadWriteBufferFromHTTP.cpp:285: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x000000001184a615 8. /build/src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x000000001184ae59 9. /build/src/IO/ReadWriteBufferFromHTTP.cpp:472: void std::__function::__policy_invoker::__call_impl[abi:se190107]>(std::__function::__policy_storage const*) @ 0x000000001184cedd 10. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001184858b 11. /build/src/IO/ReadWriteBufferFromHTTP.cpp:465: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x000000001184bf0b 12. /build/src/IO/ReadBuffer.h:60: DB::ReadBuffer::next() @ 0x000000000a148c7b 13. /build/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) @ 0x0000000011849fb2 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]>&)>&, 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&) @ 0x0000000011841980 15. /build/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) @ 0x000000001621208e 16. /build/src/Storages/StorageReplicatedMergeTree.cpp:5228: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl[abi:se190107] const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000015f9a5fe 17. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000015ed8bfd 18. /build/src/Storages/StorageReplicatedMergeTree.cpp:2514: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x0000000015ec9aab 19. /build/src/Storages/StorageReplicatedMergeTree.cpp:2349: DB::StorageReplicatedMergeTree::executeLogEntry(DB::ReplicatedMergeTreeLogEntry&) @ 0x0000000015eba91b 20. /build/src/Storages/StorageReplicatedMergeTree.cpp:3876: bool std::__function::__policy_invoker&)>::__call_impl[abi:se190107])::$_1, bool (std::shared_ptr&)>>(std::__function::__policy_storage const*, std::shared_ptr&) @ 0x0000000015f9837e 21. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000165d6fc3 22. /build/src/Storages/StorageReplicatedMergeTree.cpp:3872: DB::StorageReplicatedMergeTree::processQueueEntry(std::shared_ptr) @ 0x0000000015efc18a 23. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001624c1b2 24. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000162f9c70 25. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x00000000162fa55a 26. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc6653 27. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000000fccc4c3 28. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc3d92 29. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fcca080 30. ? @ 0x00007fbc6213eac3 31. ? @ 0x00007fbc621d0850 (version 25.3.6.10636.altinitytest (altinity build)) 2025.07.28 12:02:13.276731 [ 62055 ] {427f97ef-2861-4a0d-ba97-7e8b6002ff8f} executeQuery: Code: 394. DB::Exception: Query was cancelled. (QUERY_WAS_CANCELLED) (version 25.3.6.10636.altinitytest (altinity build)) (from [::1]:43324) (comment: 02461_cancel_finish_race.sh) (query 1, line 1) (in query: KILL QUERY WHERE current_database = 'test_dtwle8fg' SYNC FORMAT Null), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000000a074fcb 4. /build/src/Interpreters/ProcessList.cpp:567: DB::QueryStatus::throwQueryWasCancelled() const @ 0x0000000014a4bc85 5. /build/src/Interpreters/ProcessList.cpp:520: DB::QueryStatus::throwProperExceptionIfNeeded(unsigned long const&, unsigned long const&) @ 0x0000000014a4bbd9 6. /build/src/Interpreters/ProcessList.cpp:557: DB::QueryStatus::checkTimeLimit() @ 0x0000000014a4c2cd 7. /build/src/Processors/Executors/PipelineExecutor.cpp:206: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x00000000169b03a3 8. /build/src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:se190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169bfeab 9. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc3d92 10. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fcca080 11. ? @ 0x00007fbc6213eac3 12. ? @ 0x00007fbc621d0850 2025.07.28 12:02:13.331980 [ 62055 ] {} TCPHandler: Code: 394. DB::Exception: Query was cancelled. (QUERY_WAS_CANCELLED), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000000a074fcb 4. /build/src/Interpreters/ProcessList.cpp:567: DB::QueryStatus::throwQueryWasCancelled() const @ 0x0000000014a4bc85 5. /build/src/Interpreters/ProcessList.cpp:520: DB::QueryStatus::throwProperExceptionIfNeeded(unsigned long const&, unsigned long const&) @ 0x0000000014a4bbd9 6. /build/src/Interpreters/ProcessList.cpp:557: DB::QueryStatus::checkTimeLimit() @ 0x0000000014a4c2cd 7. /build/src/Processors/Executors/PipelineExecutor.cpp:206: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x00000000169b03a3 8. /build/src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:se190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169bfeab 9. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc3d92 10. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fcca080 11. ? @ 0x00007fbc6213eac3 12. ? @ 0x00007fbc621d0850 Job's origin stack trace: 0. /build/src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000000fc33b84 1. /build/src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000000fcc2ea7 2. /build/src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fcc535c 3. /build/src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000000fcc584d 4. /build/src/Common/ThreadPool.h:279: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x00000000169bf193 5. /build/src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x00000000169bf518 6. /build/src/Server/TCPHandler.cpp:1237: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x00000000168f1525 7. /build/src/Server/TCPHandler.cpp:678: DB::TCPHandler::runImpl() @ 0x00000000168e68e5 8. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 9. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 10. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 11. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 12. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 13. ? @ 0x00007fbc6213eac3 14. ? @ 0x00007fbc621d0850 2025.07.28 12:02:13.377686 [ 17203 ] {} TCPHandler: Code: 394. DB::Exception: Query was cancelled. (QUERY_WAS_CANCELLED), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000000a074fcb 4. /build/src/Interpreters/ProcessList.cpp:567: DB::QueryStatus::throwQueryWasCancelled() const @ 0x0000000014a4bc85 5. /build/src/Interpreters/ProcessList.cpp:520: DB::QueryStatus::throwProperExceptionIfNeeded(unsigned long const&, unsigned long const&) @ 0x0000000014a4bbd9 6. /build/src/Interpreters/ProcessList.cpp:557: DB::QueryStatus::checkTimeLimit() @ 0x0000000014a4c2cd 7. /build/src/Processors/Executors/PipelineExecutor.cpp:206: DB::PipelineExecutor::finalizeExecution() @ 0x00000000169b13ba 8. /build/src/Processors/Executors/PipelineExecutor.cpp:181: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x00000000169b1726 9. /build/src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x00000000169c081c 10. /build/src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x00000000169c0978 11. /build/src/Interpreters/InterpreterKillQueryQuery.cpp:439: DB::InterpreterKillQueryQuery::getSelectResult(String const&, String const&) @ 0x0000000014cf0f04 12. /build/src/Interpreters/InterpreterKillQueryQuery.cpp:222: DB::InterpreterKillQueryQuery::execute() @ 0x0000000014cebde2 13. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88dc9 14. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 15. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 16. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 17. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 18. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 19. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 20. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 21. ? @ 0x00007fbc6213eac3 22. ? @ 0x00007fbc621d0850 2025.07.28 12:02:13.392345 [ 7625 ] {} TCPHandler: Code: 394. DB::Exception: Query 'ada73a13-17da-4add-8e51-d72095ea8924' is killed in pending state. (QUERY_WAS_CANCELLED), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x000000000a06b56b 4. /build/src/Interpreters/executeQuery.cpp:1522: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c8a4ef 5. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 6. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 7. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 8. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 9. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 10. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 11. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 12. ? @ 0x00007fbc6213eac3 13. ? @ 0x00007fbc621d0850 2025.07.28 12:02:13.564798 [ 62053 ] {f248def4-e84c-48fb-b64b-f34eb4f01729} executeQuery: Code: 394. DB::Exception: Query was cancelled. (QUERY_WAS_CANCELLED) (version 25.3.6.10636.altinitytest (altinity build)) (from [::1]:43444) (comment: 02461_cancel_finish_race.sh) (query 1, line 1) (in query: KILL QUERY WHERE current_database = 'test_dtwle8fg' SYNC FORMAT Null), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000000a074fcb 4. /build/src/Interpreters/ProcessList.cpp:567: DB::QueryStatus::throwQueryWasCancelled() const @ 0x0000000014a4bc85 5. /build/src/Interpreters/ProcessList.cpp:520: DB::QueryStatus::throwProperExceptionIfNeeded(unsigned long const&, unsigned long const&) @ 0x0000000014a4bbd9 6. /build/src/Interpreters/ProcessList.cpp:557: DB::QueryStatus::checkTimeLimit() @ 0x0000000014a4c2cd 7. /build/src/Processors/Executors/PipelineExecutor.cpp:206: DB::PipelineExecutor::finalizeExecution() @ 0x00000000169b13ba 8. /build/src/Processors/Executors/PipelineExecutor.cpp:153: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x00000000169b0584 9. /build/src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:se190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169bfeab 10. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc3d92 11. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fcca080 12. ? @ 0x00007fbc6213eac3 13. ? @ 0x00007fbc621d0850 2025.07.28 12:02:13.576213 [ 62053 ] {} TCPHandler: Code: 394. DB::Exception: Query was cancelled. (QUERY_WAS_CANCELLED), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000000a074fcb 4. /build/src/Interpreters/ProcessList.cpp:567: DB::QueryStatus::throwQueryWasCancelled() const @ 0x0000000014a4bc85 5. /build/src/Interpreters/ProcessList.cpp:520: DB::QueryStatus::throwProperExceptionIfNeeded(unsigned long const&, unsigned long const&) @ 0x0000000014a4bbd9 6. /build/src/Interpreters/ProcessList.cpp:557: DB::QueryStatus::checkTimeLimit() @ 0x0000000014a4c2cd 7. /build/src/Processors/Executors/PipelineExecutor.cpp:206: DB::PipelineExecutor::finalizeExecution() @ 0x00000000169b13ba 8. /build/src/Processors/Executors/PipelineExecutor.cpp:153: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x00000000169b0584 9. /build/src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:se190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169bfeab 10. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc3d92 11. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fcca080 12. ? @ 0x00007fbc6213eac3 13. ? @ 0x00007fbc621d0850 Job's origin stack trace: 0. /build/src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000000fc33b84 1. /build/src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000000fcc2ea7 2. /build/src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fcc535c 3. /build/src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000000fcc584d 4. /build/src/Common/ThreadPool.h:279: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x00000000169bf193 5. /build/src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x00000000169bf518 6. /build/src/Server/TCPHandler.cpp:1237: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x00000000168f1525 7. /build/src/Server/TCPHandler.cpp:678: DB::TCPHandler::runImpl() @ 0x00000000168e68e5 8. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 9. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 10. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 11. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 12. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 13. ? @ 0x00007fbc6213eac3 14. ? @ 0x00007fbc621d0850 2025.07.28 12:02:13.630154 [ 5879 ] {} TCPHandler: Code: 394. DB::Exception: Query was cancelled. (QUERY_WAS_CANCELLED), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000000a074fcb 4. /build/src/Interpreters/ProcessList.cpp:567: DB::QueryStatus::throwQueryWasCancelled() const @ 0x0000000014a4bc85 5. /build/src/Interpreters/ProcessList.cpp:520: DB::QueryStatus::throwProperExceptionIfNeeded(unsigned long const&, unsigned long const&) @ 0x0000000014a4bbd9 6. /build/src/Interpreters/ProcessList.cpp:557: DB::QueryStatus::checkTimeLimit() @ 0x0000000014a4c2cd 7. /build/src/Processors/Executors/PipelineExecutor.cpp:206: DB::PipelineExecutor::finalizeExecution() @ 0x00000000169b13ba 8. /build/src/Processors/Executors/PipelineExecutor.cpp:181: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x00000000169b1726 9. /build/src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x00000000169c081c 10. /build/src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x00000000169c0978 11. /build/src/Interpreters/InterpreterKillQueryQuery.cpp:442: DB::InterpreterKillQueryQuery::getSelectResult(String const&, String const&) @ 0x0000000014cf0f6b 12. /build/src/Interpreters/InterpreterKillQueryQuery.cpp:222: DB::InterpreterKillQueryQuery::execute() @ 0x0000000014cebde2 13. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88dc9 14. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 15. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 16. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 17. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 18. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 19. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 20. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 21. ? @ 0x00007fbc6213eac3 22. ? @ 0x00007fbc621d0850 2025.07.28 12:02:13.648703 [ 62103 ] {} TCPHandler: Code: 394. DB::Exception: Query was cancelled. (QUERY_WAS_CANCELLED), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000000a074fcb 4. /build/src/Interpreters/ProcessList.cpp:567: DB::QueryStatus::throwQueryWasCancelled() const @ 0x0000000014a4bc85 5. /build/src/Interpreters/ProcessList.cpp:520: DB::QueryStatus::throwProperExceptionIfNeeded(unsigned long const&, unsigned long const&) @ 0x0000000014a4bbd9 6. /build/src/Interpreters/ProcessList.cpp:557: DB::QueryStatus::checkTimeLimit() @ 0x0000000014a4c2cd 7. /build/src/Processors/Executors/PipelineExecutor.cpp:206: DB::PipelineExecutor::finalizeExecution() @ 0x00000000169b13ba 8. /build/src/Processors/Executors/PipelineExecutor.cpp:181: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x00000000169b1726 9. /build/src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x00000000169c081c 10. /build/src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x00000000169c0978 11. /build/src/Interpreters/InterpreterKillQueryQuery.cpp:439: DB::InterpreterKillQueryQuery::getSelectResult(String const&, String const&) @ 0x0000000014cf0f04 12. /build/src/Interpreters/InterpreterKillQueryQuery.cpp:222: DB::InterpreterKillQueryQuery::execute() @ 0x0000000014cebde2 13. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88dc9 14. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 15. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 16. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 17. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 18. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 19. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 20. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 21. ? @ 0x00007fbc6213eac3 22. ? @ 0x00007fbc621d0850 2025.07.28 12:02:13.658548 [ 62093 ] {5c1cdfa8-8718-4638-ac85-5a0a914862ec} executeQuery: Code: 394. DB::Exception: Query was cancelled. (QUERY_WAS_CANCELLED) (version 25.3.6.10636.altinitytest (altinity build)) (from [::1]:43456) (comment: 02461_cancel_finish_race.sh) (query 1, line 1) (in query: KILL QUERY WHERE current_database = 'test_dtwle8fg' SYNC FORMAT Null), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000000a074fcb 4. /build/src/Interpreters/ProcessList.cpp:567: DB::QueryStatus::throwQueryWasCancelled() const @ 0x0000000014a4bc85 5. /build/src/Interpreters/ProcessList.cpp:520: DB::QueryStatus::throwProperExceptionIfNeeded(unsigned long const&, unsigned long const&) @ 0x0000000014a4bbd9 6. /build/src/Interpreters/ProcessList.cpp:557: DB::QueryStatus::checkTimeLimit() @ 0x0000000014a4c2cd 7. /build/src/Processors/Executors/PipelineExecutor.cpp:206: DB::PipelineExecutor::finalizeExecution() @ 0x00000000169b13ba 8. /build/src/Processors/Executors/PipelineExecutor.cpp:153: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x00000000169b0584 9. /build/src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:se190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169bfeab 10. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc3d92 11. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fcca080 12. ? @ 0x00007fbc6213eac3 13. ? @ 0x00007fbc621d0850 2025.07.28 12:02:13.664705 [ 62093 ] {} TCPHandler: Code: 394. DB::Exception: Query was cancelled. (QUERY_WAS_CANCELLED), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000000a074fcb 4. /build/src/Interpreters/ProcessList.cpp:567: DB::QueryStatus::throwQueryWasCancelled() const @ 0x0000000014a4bc85 5. /build/src/Interpreters/ProcessList.cpp:520: DB::QueryStatus::throwProperExceptionIfNeeded(unsigned long const&, unsigned long const&) @ 0x0000000014a4bbd9 6. /build/src/Interpreters/ProcessList.cpp:557: DB::QueryStatus::checkTimeLimit() @ 0x0000000014a4c2cd 7. /build/src/Processors/Executors/PipelineExecutor.cpp:206: DB::PipelineExecutor::finalizeExecution() @ 0x00000000169b13ba 8. /build/src/Processors/Executors/PipelineExecutor.cpp:153: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x00000000169b0584 9. /build/src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:se190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169bfeab 10. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc3d92 11. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fcca080 12. ? @ 0x00007fbc6213eac3 13. ? @ 0x00007fbc621d0850 Job's origin stack trace: 0. /build/src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000000fc33b84 1. /build/src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000000fcc2ea7 2. /build/src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fcc535c 3. /build/src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000000fcc584d 4. /build/src/Common/ThreadPool.h:279: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x00000000169bf193 5. /build/src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x00000000169bf518 6. /build/src/Server/TCPHandler.cpp:1237: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x00000000168f1525 7. /build/src/Server/TCPHandler.cpp:678: DB::TCPHandler::runImpl() @ 0x00000000168e68e5 8. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 9. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 10. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 11. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 12. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 13. ? @ 0x00007fbc6213eac3 14. ? @ 0x00007fbc621d0850 2025.07.28 12:02:13.862277 [ 17243 ] {} TCPHandler: Code: 394. DB::Exception: Query was cancelled. (QUERY_WAS_CANCELLED), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000000a074fcb 4. /build/src/Interpreters/ProcessList.cpp:567: DB::QueryStatus::throwQueryWasCancelled() const @ 0x0000000014a4bc85 5. /build/src/Interpreters/ProcessList.cpp:520: DB::QueryStatus::throwProperExceptionIfNeeded(unsigned long const&, unsigned long const&) @ 0x0000000014a4bbd9 6. /build/src/Interpreters/ProcessList.cpp:531: DB::QueryStatus::addPipelineExecutor(DB::PipelineExecutor*) @ 0x0000000014a4bd9c 7. /build/src/Processors/Executors/PipelineExecutor.cpp:73: DB::PipelineExecutor::PipelineExecutor(std::shared_ptr, std::allocator>>>&, std::shared_ptr) @ 0x00000000169afe31 8. /build/contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x00000000169c07b5 9. /build/src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x00000000169c0978 10. /build/src/Interpreters/InterpreterKillQueryQuery.cpp:439: DB::InterpreterKillQueryQuery::getSelectResult(String const&, String const&) @ 0x0000000014cf0f04 11. /build/src/Interpreters/InterpreterKillQueryQuery.cpp:222: DB::InterpreterKillQueryQuery::execute() @ 0x0000000014cebde2 12. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88dc9 13. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 14. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 15. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 16. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 17. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 18. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 19. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 20. ? @ 0x00007fbc6213eac3 21. ? @ 0x00007fbc621d0850 2025.07.28 12:02:14.046328 [ 3968 ] {} test_13.rmt2 (7f9b740d-015c-470e-8cc6-8ba33be0dc63): auto DB::StorageReplicatedMergeTree::processQueueEntry(ReplicatedMergeTreeQueue::SelectedEntryPtr)::(anonymous class)::operator()(LogEntryPtr &) const: Code: 86. DB::HTTPException: Received error from remote server http://146b4357c08d:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Ftest%2F01165%2Ftest_13%2Frmt%2Freplicas%2F1&part=20250728_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.6.10636.altinitytest (altinity build)) '. (RECEIVED_ERROR_FROM_REMOTE_IO_SERVER), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.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 const&, int&&, String const&, unsigned long&&, String const&) @ 0x000000000feda8d9 4. /build/src/IO/HTTPCommon.cpp:104: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x000000000feda6e2 5. /build/src/IO/HTTPCommon.cpp:93: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x000000000feda537 6. /build/src/IO/ReadWriteBufferFromHTTP.cpp:277: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x000000001184a4c4 7. /build/src/IO/ReadWriteBufferFromHTTP.cpp:285: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x000000001184a615 8. /build/src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x000000001184ae59 9. /build/src/IO/ReadWriteBufferFromHTTP.cpp:472: void std::__function::__policy_invoker::__call_impl[abi:se190107]>(std::__function::__policy_storage const*) @ 0x000000001184cedd 10. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001184858b 11. /build/src/IO/ReadWriteBufferFromHTTP.cpp:465: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x000000001184bf0b 12. /build/src/IO/ReadBuffer.h:60: DB::ReadBuffer::next() @ 0x000000000a148c7b 13. /build/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) @ 0x0000000011849fb2 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]>&)>&, 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&) @ 0x0000000011841980 15. /build/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) @ 0x000000001621208e 16. /build/src/Storages/StorageReplicatedMergeTree.cpp:5228: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl[abi:se190107] const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000015f9a5fe 17. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000015ed8bfd 18. /build/src/Storages/StorageReplicatedMergeTree.cpp:2514: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x0000000015ec9aab 19. /build/src/Storages/StorageReplicatedMergeTree.cpp:2349: DB::StorageReplicatedMergeTree::executeLogEntry(DB::ReplicatedMergeTreeLogEntry&) @ 0x0000000015eba91b 20. /build/src/Storages/StorageReplicatedMergeTree.cpp:3876: bool std::__function::__policy_invoker&)>::__call_impl[abi:se190107])::$_1, bool (std::shared_ptr&)>>(std::__function::__policy_storage const*, std::shared_ptr&) @ 0x0000000015f9837e 21. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000165d6fc3 22. /build/src/Storages/StorageReplicatedMergeTree.cpp:3872: DB::StorageReplicatedMergeTree::processQueueEntry(std::shared_ptr) @ 0x0000000015efc18a 23. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001624c1b2 24. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000162f9c70 25. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x00000000162fa55a 26. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc6653 27. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000000fccc4c3 28. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc3d92 29. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fcca080 30. ? @ 0x00007fbc6213eac3 31. ? @ 0x00007fbc621d0850 (version 25.3.6.10636.altinitytest (altinity build)) 2025.07.28 12:02:14.062506 [ 17255 ] {c86b4a14-6840-48f4-857f-874b702f564a} executeQuery: Code: 394. DB::Exception: Query was cancelled. (QUERY_WAS_CANCELLED) (version 25.3.6.10636.altinitytest (altinity build)) (from [::1]:43654) (comment: 02461_cancel_finish_race.sh) (query 1, line 1) (in query: KILL QUERY WHERE current_database = 'test_dtwle8fg' SYNC FORMAT Null), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000000a074fcb 4. /build/src/Interpreters/ProcessList.cpp:567: DB::QueryStatus::throwQueryWasCancelled() const @ 0x0000000014a4bc85 5. /build/src/Interpreters/ProcessList.cpp:520: DB::QueryStatus::throwProperExceptionIfNeeded(unsigned long const&, unsigned long const&) @ 0x0000000014a4bbd9 6. /build/src/Interpreters/ProcessList.cpp:557: DB::QueryStatus::checkTimeLimit() @ 0x0000000014a4c2cd 7. /build/src/Processors/Executors/PipelineExecutor.cpp:206: DB::PipelineExecutor::finalizeExecution() @ 0x00000000169b13ba 8. /build/src/Processors/Executors/PipelineExecutor.cpp:153: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x00000000169b0584 9. /build/src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:se190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169bfeab 10. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc3d92 11. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fcca080 12. ? @ 0x00007fbc6213eac3 13. ? @ 0x00007fbc621d0850 2025.07.28 12:02:14.076767 [ 17255 ] {} TCPHandler: Code: 394. DB::Exception: Query was cancelled. (QUERY_WAS_CANCELLED), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000000a074fcb 4. /build/src/Interpreters/ProcessList.cpp:567: DB::QueryStatus::throwQueryWasCancelled() const @ 0x0000000014a4bc85 5. /build/src/Interpreters/ProcessList.cpp:520: DB::QueryStatus::throwProperExceptionIfNeeded(unsigned long const&, unsigned long const&) @ 0x0000000014a4bbd9 6. /build/src/Interpreters/ProcessList.cpp:557: DB::QueryStatus::checkTimeLimit() @ 0x0000000014a4c2cd 7. /build/src/Processors/Executors/PipelineExecutor.cpp:206: DB::PipelineExecutor::finalizeExecution() @ 0x00000000169b13ba 8. /build/src/Processors/Executors/PipelineExecutor.cpp:153: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x00000000169b0584 9. /build/src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:se190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169bfeab 10. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc3d92 11. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fcca080 12. ? @ 0x00007fbc6213eac3 13. ? @ 0x00007fbc621d0850 Job's origin stack trace: 0. /build/src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000000fc33b84 1. /build/src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000000fcc2ea7 2. /build/src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fcc535c 3. /build/src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000000fcc584d 4. /build/src/Common/ThreadPool.h:279: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x00000000169bf193 5. /build/src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x00000000169bf518 6. /build/src/Server/TCPHandler.cpp:1237: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x00000000168f1525 7. /build/src/Server/TCPHandler.cpp:678: DB::TCPHandler::runImpl() @ 0x00000000168e68e5 8. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 9. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 10. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 11. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 12. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 13. ? @ 0x00007fbc6213eac3 14. ? @ 0x00007fbc621d0850 2025.07.28 12:02:14.094267 [ 62053 ] {d0b249f6-ea19-4f37-a9a0-b73ed2af0329} executeQuery: Code: 394. DB::Exception: Query was cancelled. (QUERY_WAS_CANCELLED) (version 25.3.6.10636.altinitytest (altinity build)) (from [::1]:43688) (comment: 02461_cancel_finish_race.sh) (query 1, line 1) (in query: KILL QUERY WHERE current_database = 'test_dtwle8fg' SYNC FORMAT Null), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000000a074fcb 4. /build/src/Interpreters/ProcessList.cpp:567: DB::QueryStatus::throwQueryWasCancelled() const @ 0x0000000014a4bc85 5. /build/src/Interpreters/ProcessList.cpp:520: DB::QueryStatus::throwProperExceptionIfNeeded(unsigned long const&, unsigned long const&) @ 0x0000000014a4bbd9 6. /build/src/Interpreters/ProcessList.cpp:557: DB::QueryStatus::checkTimeLimit() @ 0x0000000014a4c2cd 7. /build/src/Processors/Executors/PipelineExecutor.cpp:206: DB::PipelineExecutor::finalizeExecution() @ 0x00000000169b13ba 8. /build/src/Processors/Executors/PipelineExecutor.cpp:153: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x00000000169b0584 9. /build/src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:se190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169bfeab 10. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc3d92 11. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fcca080 12. ? @ 0x00007fbc6213eac3 13. ? @ 0x00007fbc621d0850 2025.07.28 12:02:14.103624 [ 62053 ] {} TCPHandler: Code: 394. DB::Exception: Query was cancelled. (QUERY_WAS_CANCELLED), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000000a074fcb 4. /build/src/Interpreters/ProcessList.cpp:567: DB::QueryStatus::throwQueryWasCancelled() const @ 0x0000000014a4bc85 5. /build/src/Interpreters/ProcessList.cpp:520: DB::QueryStatus::throwProperExceptionIfNeeded(unsigned long const&, unsigned long const&) @ 0x0000000014a4bbd9 6. /build/src/Interpreters/ProcessList.cpp:557: DB::QueryStatus::checkTimeLimit() @ 0x0000000014a4c2cd 7. /build/src/Processors/Executors/PipelineExecutor.cpp:206: DB::PipelineExecutor::finalizeExecution() @ 0x00000000169b13ba 8. /build/src/Processors/Executors/PipelineExecutor.cpp:153: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x00000000169b0584 9. /build/src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:se190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169bfeab 10. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc3d92 11. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fcca080 12. ? @ 0x00007fbc6213eac3 13. ? @ 0x00007fbc621d0850 Job's origin stack trace: 0. /build/src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000000fc33b84 1. /build/src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000000fcc2ea7 2. /build/src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fcc535c 3. /build/src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000000fcc584d 4. /build/src/Common/ThreadPool.h:279: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x00000000169bf193 5. /build/src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x00000000169bf518 6. /build/src/Server/TCPHandler.cpp:1237: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x00000000168f1525 7. /build/src/Server/TCPHandler.cpp:678: DB::TCPHandler::runImpl() @ 0x00000000168e68e5 8. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 9. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 10. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 11. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 12. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 13. ? @ 0x00007fbc6213eac3 14. ? @ 0x00007fbc621d0850 2025.07.28 12:02:14.148019 [ 4963 ] {} TCPHandler: Code: 394. DB::Exception: Query was cancelled. (QUERY_WAS_CANCELLED), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000000a074fcb 4. /build/src/Interpreters/ProcessList.cpp:567: DB::QueryStatus::throwQueryWasCancelled() const @ 0x0000000014a4bc85 5. /build/src/Interpreters/ProcessList.cpp:520: DB::QueryStatus::throwProperExceptionIfNeeded(unsigned long const&, unsigned long const&) @ 0x0000000014a4bbd9 6. /build/src/Interpreters/ProcessList.cpp:557: DB::QueryStatus::checkTimeLimit() @ 0x0000000014a4c2cd 7. /build/src/Processors/Executors/PipelineExecutor.cpp:206: DB::PipelineExecutor::finalizeExecution() @ 0x00000000169b13ba 8. /build/src/Processors/Executors/PipelineExecutor.cpp:181: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x00000000169b1726 9. /build/src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x00000000169c081c 10. /build/src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x00000000169c0978 11. /build/src/Interpreters/InterpreterKillQueryQuery.cpp:439: DB::InterpreterKillQueryQuery::getSelectResult(String const&, String const&) @ 0x0000000014cf0f04 12. /build/src/Interpreters/InterpreterKillQueryQuery.cpp:222: DB::InterpreterKillQueryQuery::execute() @ 0x0000000014cebde2 13. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88dc9 14. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 15. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 16. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 17. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 18. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 19. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 20. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 21. ? @ 0x00007fbc6213eac3 22. ? @ 0x00007fbc621d0850 2025.07.28 12:02:14.163831 [ 62075 ] {9bee53a5-b7b9-4fce-8640-24cefbb2898b} executeQuery: Code: 394. DB::Exception: Query was cancelled. (QUERY_WAS_CANCELLED) (version 25.3.6.10636.altinitytest (altinity build)) (from [::1]:43638) (comment: 02461_cancel_finish_race.sh) (query 1, line 1) (in query: KILL QUERY WHERE current_database = 'test_dtwle8fg' SYNC FORMAT Null), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000000a074fcb 4. /build/src/Interpreters/ProcessList.cpp:567: DB::QueryStatus::throwQueryWasCancelled() const @ 0x0000000014a4bc85 5. /build/src/Interpreters/ProcessList.cpp:520: DB::QueryStatus::throwProperExceptionIfNeeded(unsigned long const&, unsigned long const&) @ 0x0000000014a4bbd9 6. /build/src/Interpreters/ProcessList.cpp:557: DB::QueryStatus::checkTimeLimit() @ 0x0000000014a4c2cd 7. /build/src/Processors/Executors/PipelineExecutor.cpp:206: DB::PipelineExecutor::finalizeExecution() @ 0x00000000169b13ba 8. /build/src/Processors/Executors/PipelineExecutor.cpp:153: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x00000000169b0584 9. /build/src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:se190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169bfeab 10. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc3d92 11. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fcca080 12. ? @ 0x00007fbc6213eac3 13. ? @ 0x00007fbc621d0850 2025.07.28 12:02:14.175429 [ 62075 ] {} TCPHandler: Code: 394. DB::Exception: Query was cancelled. (QUERY_WAS_CANCELLED), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000000a074fcb 4. /build/src/Interpreters/ProcessList.cpp:567: DB::QueryStatus::throwQueryWasCancelled() const @ 0x0000000014a4bc85 5. /build/src/Interpreters/ProcessList.cpp:520: DB::QueryStatus::throwProperExceptionIfNeeded(unsigned long const&, unsigned long const&) @ 0x0000000014a4bbd9 6. /build/src/Interpreters/ProcessList.cpp:557: DB::QueryStatus::checkTimeLimit() @ 0x0000000014a4c2cd 7. /build/src/Processors/Executors/PipelineExecutor.cpp:206: DB::PipelineExecutor::finalizeExecution() @ 0x00000000169b13ba 8. /build/src/Processors/Executors/PipelineExecutor.cpp:153: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x00000000169b0584 9. /build/src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:se190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169bfeab 10. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc3d92 11. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fcca080 12. ? @ 0x00007fbc6213eac3 13. ? @ 0x00007fbc621d0850 Job's origin stack trace: 0. /build/src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000000fc33b84 1. /build/src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000000fcc2ea7 2. /build/src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fcc535c 3. /build/src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000000fcc584d 4. /build/src/Common/ThreadPool.h:279: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x00000000169bf193 5. /build/src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x00000000169bf518 6. /build/src/Server/TCPHandler.cpp:1237: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x00000000168f1525 7. /build/src/Server/TCPHandler.cpp:678: DB::TCPHandler::runImpl() @ 0x00000000168e68e5 8. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 9. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 10. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 11. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 12. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 13. ? @ 0x00007fbc6213eac3 14. ? @ 0x00007fbc621d0850 2025.07.28 12:02:14.200138 [ 62103 ] {c3aaa612-c955-493c-9296-7ae18e3acaaf} executeQuery: Code: 394. DB::Exception: Query was cancelled. (QUERY_WAS_CANCELLED) (version 25.3.6.10636.altinitytest (altinity build)) (from [::1]:43684) (comment: 02461_cancel_finish_race.sh) (query 1, line 1) (in query: KILL QUERY WHERE current_database = 'test_dtwle8fg' SYNC FORMAT Null), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000000a074fcb 4. /build/src/Interpreters/ProcessList.cpp:567: DB::QueryStatus::throwQueryWasCancelled() const @ 0x0000000014a4bc85 5. /build/src/Interpreters/ProcessList.cpp:520: DB::QueryStatus::throwProperExceptionIfNeeded(unsigned long const&, unsigned long const&) @ 0x0000000014a4bbd9 6. /build/src/Interpreters/ProcessList.cpp:557: DB::QueryStatus::checkTimeLimit() @ 0x0000000014a4c2cd 7. /build/src/Processors/Executors/PipelineExecutor.cpp:206: DB::PipelineExecutor::finalizeExecution() @ 0x00000000169b13ba 8. /build/src/Processors/Executors/PipelineExecutor.cpp:153: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x00000000169b0584 9. /build/src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:se190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169bfeab 10. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc3d92 11. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fcca080 12. ? @ 0x00007fbc6213eac3 13. ? @ 0x00007fbc621d0850 2025.07.28 12:02:14.217590 [ 62103 ] {} TCPHandler: Code: 394. DB::Exception: Query was cancelled. (QUERY_WAS_CANCELLED), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000000a074fcb 4. /build/src/Interpreters/ProcessList.cpp:567: DB::QueryStatus::throwQueryWasCancelled() const @ 0x0000000014a4bc85 5. /build/src/Interpreters/ProcessList.cpp:520: DB::QueryStatus::throwProperExceptionIfNeeded(unsigned long const&, unsigned long const&) @ 0x0000000014a4bbd9 6. /build/src/Interpreters/ProcessList.cpp:557: DB::QueryStatus::checkTimeLimit() @ 0x0000000014a4c2cd 7. /build/src/Processors/Executors/PipelineExecutor.cpp:206: DB::PipelineExecutor::finalizeExecution() @ 0x00000000169b13ba 8. /build/src/Processors/Executors/PipelineExecutor.cpp:153: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x00000000169b0584 9. /build/src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:se190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169bfeab 10. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc3d92 11. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fcca080 12. ? @ 0x00007fbc6213eac3 13. ? @ 0x00007fbc621d0850 Job's origin stack trace: 0. /build/src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000000fc33b84 1. /build/src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000000fcc2ea7 2. /build/src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fcc535c 3. /build/src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000000fcc584d 4. /build/src/Common/ThreadPool.h:279: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x00000000169bf193 5. /build/src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x00000000169bf518 6. /build/src/Server/TCPHandler.cpp:1237: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x00000000168f1525 7. /build/src/Server/TCPHandler.cpp:678: DB::TCPHandler::runImpl() @ 0x00000000168e68e5 8. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 9. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 10. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 11. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 12. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 13. ? @ 0x00007fbc6213eac3 14. ? @ 0x00007fbc621d0850 2025.07.28 12:02:14.549608 [ 17252 ] {2d933100-94aa-4180-b526-893769811a19} executeQuery: Code: 394. DB::Exception: Query was cancelled. (QUERY_WAS_CANCELLED) (version 25.3.6.10636.altinitytest (altinity build)) (from [::1]:43822) (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. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000000a074fcb 4. /build/src/Interpreters/ProcessList.cpp:567: DB::QueryStatus::throwQueryWasCancelled() const @ 0x0000000014a4bc85 5. /build/src/Interpreters/ProcessList.cpp:520: DB::QueryStatus::throwProperExceptionIfNeeded(unsigned long const&, unsigned long const&) @ 0x0000000014a4bbd9 6. /build/src/Interpreters/ProcessList.cpp:557: DB::QueryStatus::checkTimeLimit() @ 0x0000000014a4c2cd 7. /build/src/Processors/Executors/PipelineExecutor.cpp:206: DB::PipelineExecutor::finalizeExecution() @ 0x00000000169b13ba 8. /build/src/Processors/Executors/PipelineExecutor.cpp:153: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x00000000169b0584 9. /build/src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:se190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169bfeab 10. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc3d92 11. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fcca080 12. ? @ 0x00007fbc6213eac3 13. ? @ 0x00007fbc621d0850 2025.07.28 12:02:14.569357 [ 17252 ] {} TCPHandler: Code: 394. DB::Exception: Query was cancelled. (QUERY_WAS_CANCELLED), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000000a074fcb 4. /build/src/Interpreters/ProcessList.cpp:567: DB::QueryStatus::throwQueryWasCancelled() const @ 0x0000000014a4bc85 5. /build/src/Interpreters/ProcessList.cpp:520: DB::QueryStatus::throwProperExceptionIfNeeded(unsigned long const&, unsigned long const&) @ 0x0000000014a4bbd9 6. /build/src/Interpreters/ProcessList.cpp:557: DB::QueryStatus::checkTimeLimit() @ 0x0000000014a4c2cd 7. /build/src/Processors/Executors/PipelineExecutor.cpp:206: DB::PipelineExecutor::finalizeExecution() @ 0x00000000169b13ba 8. /build/src/Processors/Executors/PipelineExecutor.cpp:153: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x00000000169b0584 9. /build/src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:se190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169bfeab 10. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc3d92 11. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fcca080 12. ? @ 0x00007fbc6213eac3 13. ? @ 0x00007fbc621d0850 Job's origin stack trace: 0. /build/src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000000fc33b84 1. /build/src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000000fcc2ea7 2. /build/src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fcc535c 3. /build/src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000000fcc584d 4. /build/src/Common/ThreadPool.h:279: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x00000000169bf193 5. /build/src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x00000000169bf518 6. /build/src/Server/TCPHandler.cpp:1237: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x00000000168f1525 7. /build/src/Server/TCPHandler.cpp:678: DB::TCPHandler::runImpl() @ 0x00000000168e68e5 8. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 9. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 10. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 11. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 12. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 13. ? @ 0x00007fbc6213eac3 14. ? @ 0x00007fbc621d0850 2025.07.28 12:02:14.584828 [ 62056 ] {} TCPHandler: Code: 394. DB::Exception: Query was cancelled. (QUERY_WAS_CANCELLED), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000000a074fcb 4. /build/src/Interpreters/ProcessList.cpp:567: DB::QueryStatus::throwQueryWasCancelled() const @ 0x0000000014a4bc85 5. /build/src/Interpreters/ProcessList.cpp:520: DB::QueryStatus::throwProperExceptionIfNeeded(unsigned long const&, unsigned long const&) @ 0x0000000014a4bbd9 6. /build/src/Interpreters/ProcessList.cpp:557: DB::QueryStatus::checkTimeLimit() @ 0x0000000014a4c2cd 7. /build/src/Processors/Executors/PipelineExecutor.cpp:206: DB::PipelineExecutor::finalizeExecution() @ 0x00000000169b13ba 8. /build/src/Processors/Executors/PipelineExecutor.cpp:181: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x00000000169b1726 9. /build/src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x00000000169c081c 10. /build/src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x00000000169c0978 11. /build/src/Interpreters/InterpreterKillQueryQuery.cpp:442: DB::InterpreterKillQueryQuery::getSelectResult(String const&, String const&) @ 0x0000000014cf0f6b 12. /build/src/Interpreters/InterpreterKillQueryQuery.cpp:222: DB::InterpreterKillQueryQuery::execute() @ 0x0000000014cebde2 13. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88dc9 14. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 15. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 16. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 17. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 18. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 19. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 20. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 21. ? @ 0x00007fbc6213eac3 22. ? @ 0x00007fbc621d0850 2025.07.28 12:02:14.596846 [ 17255 ] {} TCPHandler: Code: 394. DB::Exception: Query was cancelled. (QUERY_WAS_CANCELLED), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000000a074fcb 4. /build/src/Interpreters/ProcessList.cpp:567: DB::QueryStatus::throwQueryWasCancelled() const @ 0x0000000014a4bc85 5. /build/src/Interpreters/ProcessList.cpp:520: DB::QueryStatus::throwProperExceptionIfNeeded(unsigned long const&, unsigned long const&) @ 0x0000000014a4bbd9 6. /build/src/Interpreters/ProcessList.cpp:531: DB::QueryStatus::addPipelineExecutor(DB::PipelineExecutor*) @ 0x0000000014a4bd9c 7. /build/src/Processors/Executors/PipelineExecutor.cpp:73: DB::PipelineExecutor::PipelineExecutor(std::shared_ptr, std::allocator>>>&, std::shared_ptr) @ 0x00000000169afe31 8. /build/contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x00000000169c07b5 9. /build/src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x00000000169c0978 10. /build/src/Interpreters/InterpreterKillQueryQuery.cpp:439: DB::InterpreterKillQueryQuery::getSelectResult(String const&, String const&) @ 0x0000000014cf0f04 11. /build/src/Interpreters/InterpreterKillQueryQuery.cpp:222: DB::InterpreterKillQueryQuery::execute() @ 0x0000000014cebde2 12. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88dc9 13. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 14. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 15. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 16. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 17. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 18. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 19. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 20. ? @ 0x00007fbc6213eac3 21. ? @ 0x00007fbc621d0850 2025.07.28 12:02:14.644177 [ 17203 ] {} TCPHandler: Code: 394. DB::Exception: Query was cancelled. (QUERY_WAS_CANCELLED), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000000a074fcb 4. /build/src/Interpreters/ProcessList.cpp:567: DB::QueryStatus::throwQueryWasCancelled() const @ 0x0000000014a4bc85 5. /build/src/Interpreters/ProcessList.cpp:520: DB::QueryStatus::throwProperExceptionIfNeeded(unsigned long const&, unsigned long const&) @ 0x0000000014a4bbd9 6. /build/src/Interpreters/ProcessList.cpp:531: DB::QueryStatus::addPipelineExecutor(DB::PipelineExecutor*) @ 0x0000000014a4bd9c 7. /build/src/Processors/Executors/PipelineExecutor.cpp:73: DB::PipelineExecutor::PipelineExecutor(std::shared_ptr, std::allocator>>>&, std::shared_ptr) @ 0x00000000169afe31 8. /build/contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x00000000169c07b5 9. /build/src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x00000000169c0978 10. /build/src/Interpreters/InterpreterKillQueryQuery.cpp:439: DB::InterpreterKillQueryQuery::getSelectResult(String const&, String const&) @ 0x0000000014cf0f04 11. /build/src/Interpreters/InterpreterKillQueryQuery.cpp:222: DB::InterpreterKillQueryQuery::execute() @ 0x0000000014cebde2 12. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88dc9 13. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 14. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 15. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 16. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 17. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 18. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 19. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 20. ? @ 0x00007fbc6213eac3 21. ? @ 0x00007fbc621d0850 2025.07.28 12:02:14.702758 [ 17232 ] {b7335868-e938-4acf-a1c0-e52df297b69b} executeQuery: Code: 394. DB::Exception: Query was cancelled. (QUERY_WAS_CANCELLED) (version 25.3.6.10636.altinitytest (altinity build)) (from [::1]:43796) (comment: 02461_cancel_finish_race.sh) (query 1, line 1) (in query: KILL QUERY WHERE current_database = 'test_dtwle8fg' SYNC FORMAT Null), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000000a074fcb 4. /build/src/Interpreters/ProcessList.cpp:567: DB::QueryStatus::throwQueryWasCancelled() const @ 0x0000000014a4bc85 5. /build/src/Interpreters/ProcessList.cpp:520: DB::QueryStatus::throwProperExceptionIfNeeded(unsigned long const&, unsigned long const&) @ 0x0000000014a4bbd9 6. /build/src/Interpreters/ProcessList.cpp:557: DB::QueryStatus::checkTimeLimit() @ 0x0000000014a4c2cd 7. /build/src/Processors/Executors/PipelineExecutor.cpp:206: DB::PipelineExecutor::finalizeExecution() @ 0x00000000169b13ba 8. /build/src/Processors/Executors/PipelineExecutor.cpp:153: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x00000000169b0584 9. /build/src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:se190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169bfeab 10. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc3d92 11. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fcca080 12. ? @ 0x00007fbc6213eac3 13. ? @ 0x00007fbc621d0850 2025.07.28 12:02:14.708141 [ 17232 ] {} TCPHandler: Code: 394. DB::Exception: Query was cancelled. (QUERY_WAS_CANCELLED), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000000a074fcb 4. /build/src/Interpreters/ProcessList.cpp:567: DB::QueryStatus::throwQueryWasCancelled() const @ 0x0000000014a4bc85 5. /build/src/Interpreters/ProcessList.cpp:520: DB::QueryStatus::throwProperExceptionIfNeeded(unsigned long const&, unsigned long const&) @ 0x0000000014a4bbd9 6. /build/src/Interpreters/ProcessList.cpp:557: DB::QueryStatus::checkTimeLimit() @ 0x0000000014a4c2cd 7. /build/src/Processors/Executors/PipelineExecutor.cpp:206: DB::PipelineExecutor::finalizeExecution() @ 0x00000000169b13ba 8. /build/src/Processors/Executors/PipelineExecutor.cpp:153: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x00000000169b0584 9. /build/src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:se190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169bfeab 10. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc3d92 11. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fcca080 12. ? @ 0x00007fbc6213eac3 13. ? @ 0x00007fbc621d0850 Job's origin stack trace: 0. /build/src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000000fc33b84 1. /build/src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000000fcc2ea7 2. /build/src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fcc535c 3. /build/src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000000fcc584d 4. /build/src/Common/ThreadPool.h:279: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x00000000169bf193 5. /build/src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x00000000169bf518 6. /build/src/Server/TCPHandler.cpp:1237: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x00000000168f1525 7. /build/src/Server/TCPHandler.cpp:678: DB::TCPHandler::runImpl() @ 0x00000000168e68e5 8. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 9. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 10. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 11. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 12. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 13. ? @ 0x00007fbc6213eac3 14. ? @ 0x00007fbc621d0850 2025.07.28 12:02:14.810703 [ 62053 ] {a2dae9bc-4277-4b52-85b6-0c62dc4693ff} executeQuery: Code: 394. DB::Exception: Query was cancelled. (QUERY_WAS_CANCELLED) (version 25.3.6.10636.altinitytest (altinity build)) (from [::1]:43858) (comment: 02461_cancel_finish_race.sh) (query 1, line 1) (in query: KILL QUERY WHERE current_database = 'test_dtwle8fg' SYNC FORMAT Null), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000000a074fcb 4. /build/src/Interpreters/ProcessList.cpp:567: DB::QueryStatus::throwQueryWasCancelled() const @ 0x0000000014a4bc85 5. /build/src/Interpreters/ProcessList.cpp:520: DB::QueryStatus::throwProperExceptionIfNeeded(unsigned long const&, unsigned long const&) @ 0x0000000014a4bbd9 6. /build/src/Interpreters/ProcessList.cpp:557: DB::QueryStatus::checkTimeLimit() @ 0x0000000014a4c2cd 7. /build/src/Processors/Executors/PipelineExecutor.cpp:206: DB::PipelineExecutor::finalizeExecution() @ 0x00000000169b13ba 8. /build/src/Processors/Executors/PipelineExecutor.cpp:153: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x00000000169b0584 9. /build/src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:se190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169bfeab 10. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc3d92 11. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fcca080 12. ? @ 0x00007fbc6213eac3 13. ? @ 0x00007fbc621d0850 2025.07.28 12:02:14.824337 [ 62053 ] {} TCPHandler: Code: 394. DB::Exception: Query was cancelled. (QUERY_WAS_CANCELLED), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000000a074fcb 4. /build/src/Interpreters/ProcessList.cpp:567: DB::QueryStatus::throwQueryWasCancelled() const @ 0x0000000014a4bc85 5. /build/src/Interpreters/ProcessList.cpp:520: DB::QueryStatus::throwProperExceptionIfNeeded(unsigned long const&, unsigned long const&) @ 0x0000000014a4bbd9 6. /build/src/Interpreters/ProcessList.cpp:557: DB::QueryStatus::checkTimeLimit() @ 0x0000000014a4c2cd 7. /build/src/Processors/Executors/PipelineExecutor.cpp:206: DB::PipelineExecutor::finalizeExecution() @ 0x00000000169b13ba 8. /build/src/Processors/Executors/PipelineExecutor.cpp:153: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x00000000169b0584 9. /build/src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:se190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169bfeab 10. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc3d92 11. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fcca080 12. ? @ 0x00007fbc6213eac3 13. ? @ 0x00007fbc621d0850 Job's origin stack trace: 0. /build/src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000000fc33b84 1. /build/src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000000fcc2ea7 2. /build/src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fcc535c 3. /build/src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000000fcc584d 4. /build/src/Common/ThreadPool.h:279: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x00000000169bf193 5. /build/src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x00000000169bf518 6. /build/src/Server/TCPHandler.cpp:1237: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x00000000168f1525 7. /build/src/Server/TCPHandler.cpp:678: DB::TCPHandler::runImpl() @ 0x00000000168e68e5 8. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 9. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 10. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 11. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 12. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 13. ? @ 0x00007fbc6213eac3 14. ? @ 0x00007fbc621d0850 2025.07.28 12:02:14.897331 [ 3965 ] {} test_13.rmt2 (7f9b740d-015c-470e-8cc6-8ba33be0dc63): auto DB::StorageReplicatedMergeTree::processQueueEntry(ReplicatedMergeTreeQueue::SelectedEntryPtr)::(anonymous class)::operator()(LogEntryPtr &) const: Code: 86. DB::HTTPException: Received error from remote server http://146b4357c08d:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Ftest%2F01165%2Ftest_13%2Frmt%2Freplicas%2F1&part=20250728_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.6.10636.altinitytest (altinity build)) '. (RECEIVED_ERROR_FROM_REMOTE_IO_SERVER), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.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 const&, int&&, String const&, unsigned long&&, String const&) @ 0x000000000feda8d9 4. /build/src/IO/HTTPCommon.cpp:104: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x000000000feda6e2 5. /build/src/IO/HTTPCommon.cpp:93: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x000000000feda537 6. /build/src/IO/ReadWriteBufferFromHTTP.cpp:277: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x000000001184a4c4 7. /build/src/IO/ReadWriteBufferFromHTTP.cpp:285: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x000000001184a615 8. /build/src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x000000001184ae59 9. /build/src/IO/ReadWriteBufferFromHTTP.cpp:472: void std::__function::__policy_invoker::__call_impl[abi:se190107]>(std::__function::__policy_storage const*) @ 0x000000001184cedd 10. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001184858b 11. /build/src/IO/ReadWriteBufferFromHTTP.cpp:465: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x000000001184bf0b 12. /build/src/IO/ReadBuffer.h:60: DB::ReadBuffer::next() @ 0x000000000a148c7b 13. /build/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) @ 0x0000000011849fb2 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]>&)>&, 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&) @ 0x0000000011841980 15. /build/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) @ 0x000000001621208e 16. /build/src/Storages/StorageReplicatedMergeTree.cpp:5228: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl[abi:se190107] const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000015f9a5fe 17. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000015ed8bfd 18. /build/src/Storages/StorageReplicatedMergeTree.cpp:2514: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x0000000015ec9aab 19. /build/src/Storages/StorageReplicatedMergeTree.cpp:2349: DB::StorageReplicatedMergeTree::executeLogEntry(DB::ReplicatedMergeTreeLogEntry&) @ 0x0000000015eba91b 20. /build/src/Storages/StorageReplicatedMergeTree.cpp:3876: bool std::__function::__policy_invoker&)>::__call_impl[abi:se190107])::$_1, bool (std::shared_ptr&)>>(std::__function::__policy_storage const*, std::shared_ptr&) @ 0x0000000015f9837e 21. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000165d6fc3 22. /build/src/Storages/StorageReplicatedMergeTree.cpp:3872: DB::StorageReplicatedMergeTree::processQueueEntry(std::shared_ptr) @ 0x0000000015efc18a 23. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001624c1b2 24. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000162f9c70 25. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x00000000162fa55a 26. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc6653 27. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000000fccc4c3 28. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc3d92 29. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fcca080 30. ? @ 0x00007fbc6213eac3 31. ? @ 0x00007fbc621d0850 (version 25.3.6.10636.altinitytest (altinity build)) 2025.07.28 12:02:14.968614 [ 11826 ] {} TCPHandler: Code: 394. DB::Exception: Query was cancelled. (QUERY_WAS_CANCELLED), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000000a074fcb 4. /build/src/Interpreters/ProcessList.cpp:567: DB::QueryStatus::throwQueryWasCancelled() const @ 0x0000000014a4bc85 5. /build/src/Interpreters/ProcessList.cpp:520: DB::QueryStatus::throwProperExceptionIfNeeded(unsigned long const&, unsigned long const&) @ 0x0000000014a4bbd9 6. /build/src/Interpreters/ProcessList.cpp:531: DB::QueryStatus::addPipelineExecutor(DB::PipelineExecutor*) @ 0x0000000014a4bd9c 7. /build/src/Processors/Executors/PipelineExecutor.cpp:73: DB::PipelineExecutor::PipelineExecutor(std::shared_ptr, std::allocator>>>&, std::shared_ptr) @ 0x00000000169afe31 8. /build/contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x00000000169c07b5 9. /build/src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x00000000169c0978 10. /build/src/Interpreters/InterpreterKillQueryQuery.cpp:439: DB::InterpreterKillQueryQuery::getSelectResult(String const&, String const&) @ 0x0000000014cf0f04 11. /build/src/Interpreters/InterpreterKillQueryQuery.cpp:222: DB::InterpreterKillQueryQuery::execute() @ 0x0000000014cebde2 12. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88dc9 13. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 14. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 15. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 16. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 17. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 18. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 19. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 20. ? @ 0x00007fbc6213eac3 21. ? @ 0x00007fbc621d0850 2025.07.28 12:02:14.999778 [ 62093 ] {} TCPHandler: Code: 394. DB::Exception: Query was cancelled. (QUERY_WAS_CANCELLED), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000000a074fcb 4. /build/src/Interpreters/ProcessList.cpp:567: DB::QueryStatus::throwQueryWasCancelled() const @ 0x0000000014a4bc85 5. /build/src/Interpreters/ProcessList.cpp:520: DB::QueryStatus::throwProperExceptionIfNeeded(unsigned long const&, unsigned long const&) @ 0x0000000014a4bbd9 6. /build/src/Interpreters/ProcessList.cpp:531: DB::QueryStatus::addPipelineExecutor(DB::PipelineExecutor*) @ 0x0000000014a4bd9c 7. /build/src/Processors/Executors/PipelineExecutor.cpp:73: DB::PipelineExecutor::PipelineExecutor(std::shared_ptr, std::allocator>>>&, std::shared_ptr) @ 0x00000000169afe31 8. /build/contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x00000000169c07b5 9. /build/src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x00000000169c0978 10. /build/src/Interpreters/InterpreterKillQueryQuery.cpp:439: DB::InterpreterKillQueryQuery::getSelectResult(String const&, String const&) @ 0x0000000014cf0f04 11. /build/src/Interpreters/InterpreterKillQueryQuery.cpp:222: DB::InterpreterKillQueryQuery::execute() @ 0x0000000014cebde2 12. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88dc9 13. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 14. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 15. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 16. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 17. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 18. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 19. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 20. ? @ 0x00007fbc6213eac3 21. ? @ 0x00007fbc621d0850 2025.07.28 12:02:15.030073 [ 62056 ] {} TCPHandler: Code: 394. DB::Exception: Query was cancelled. (QUERY_WAS_CANCELLED), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000000a074fcb 4. /build/src/Interpreters/ProcessList.cpp:567: DB::QueryStatus::throwQueryWasCancelled() const @ 0x0000000014a4bc85 5. /build/src/Interpreters/ProcessList.cpp:520: DB::QueryStatus::throwProperExceptionIfNeeded(unsigned long const&, unsigned long const&) @ 0x0000000014a4bbd9 6. /build/src/Interpreters/ProcessList.cpp:557: DB::QueryStatus::checkTimeLimit() @ 0x0000000014a4c2cd 7. /build/src/Processors/Executors/PipelineExecutor.cpp:206: DB::PipelineExecutor::finalizeExecution() @ 0x00000000169b13ba 8. /build/src/Processors/Executors/PipelineExecutor.cpp:181: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x00000000169b1726 9. /build/src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x00000000169c081c 10. /build/src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x00000000169c0978 11. /build/src/Interpreters/InterpreterKillQueryQuery.cpp:442: DB::InterpreterKillQueryQuery::getSelectResult(String const&, String const&) @ 0x0000000014cf0f6b 12. /build/src/Interpreters/InterpreterKillQueryQuery.cpp:222: DB::InterpreterKillQueryQuery::execute() @ 0x0000000014cebde2 13. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88dc9 14. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 15. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 16. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 17. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 18. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 19. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 20. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 21. ? @ 0x00007fbc6213eac3 22. ? @ 0x00007fbc621d0850 2025.07.28 12:02:15.084577 [ 62075 ] {46911976-407f-4e44-8c0a-72f28042534b} executeQuery: Code: 394. DB::Exception: Query was cancelled. (QUERY_WAS_CANCELLED) (version 25.3.6.10636.altinitytest (altinity build)) (from [::1]:43890) (comment: 02461_cancel_finish_race.sh) (query 1, line 1) (in query: KILL QUERY WHERE current_database = 'test_dtwle8fg' SYNC FORMAT Null), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000000a074fcb 4. /build/src/Interpreters/ProcessList.cpp:567: DB::QueryStatus::throwQueryWasCancelled() const @ 0x0000000014a4bc85 5. /build/src/Interpreters/ProcessList.cpp:520: DB::QueryStatus::throwProperExceptionIfNeeded(unsigned long const&, unsigned long const&) @ 0x0000000014a4bbd9 6. /build/src/Interpreters/ProcessList.cpp:557: DB::QueryStatus::checkTimeLimit() @ 0x0000000014a4c2cd 7. /build/src/Processors/Executors/PipelineExecutor.cpp:206: DB::PipelineExecutor::finalizeExecution() @ 0x00000000169b13ba 8. /build/src/Processors/Executors/PipelineExecutor.cpp:153: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x00000000169b0584 9. /build/src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:se190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169bfeab 10. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc3d92 11. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fcca080 12. ? @ 0x00007fbc6213eac3 13. ? @ 0x00007fbc621d0850 2025.07.28 12:02:15.101682 [ 62075 ] {} TCPHandler: Code: 394. DB::Exception: Query was cancelled. (QUERY_WAS_CANCELLED), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000000a074fcb 4. /build/src/Interpreters/ProcessList.cpp:567: DB::QueryStatus::throwQueryWasCancelled() const @ 0x0000000014a4bc85 5. /build/src/Interpreters/ProcessList.cpp:520: DB::QueryStatus::throwProperExceptionIfNeeded(unsigned long const&, unsigned long const&) @ 0x0000000014a4bbd9 6. /build/src/Interpreters/ProcessList.cpp:557: DB::QueryStatus::checkTimeLimit() @ 0x0000000014a4c2cd 7. /build/src/Processors/Executors/PipelineExecutor.cpp:206: DB::PipelineExecutor::finalizeExecution() @ 0x00000000169b13ba 8. /build/src/Processors/Executors/PipelineExecutor.cpp:153: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x00000000169b0584 9. /build/src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:se190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169bfeab 10. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc3d92 11. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fcca080 12. ? @ 0x00007fbc6213eac3 13. ? @ 0x00007fbc621d0850 Job's origin stack trace: 0. /build/src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000000fc33b84 1. /build/src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000000fcc2ea7 2. /build/src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fcc535c 3. /build/src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000000fcc584d 4. /build/src/Common/ThreadPool.h:279: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x00000000169bf193 5. /build/src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x00000000169bf518 6. /build/src/Server/TCPHandler.cpp:1237: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x00000000168f1525 7. /build/src/Server/TCPHandler.cpp:678: DB::TCPHandler::runImpl() @ 0x00000000168e68e5 8. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 9. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 10. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 11. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 12. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 13. ? @ 0x00007fbc6213eac3 14. ? @ 0x00007fbc621d0850 2025.07.28 12:02:15.109854 [ 17255 ] {8cefee98-9d15-41a6-b430-5b0468965de2} executeQuery: Code: 394. DB::Exception: Query was cancelled. (QUERY_WAS_CANCELLED) (version 25.3.6.10636.altinitytest (altinity build)) (from [::1]:44000) (comment: 02461_cancel_finish_race.sh) (query 1, line 1) (in query: KILL QUERY WHERE current_database = 'test_dtwle8fg' SYNC FORMAT Null), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000000a074fcb 4. /build/src/Interpreters/ProcessList.cpp:567: DB::QueryStatus::throwQueryWasCancelled() const @ 0x0000000014a4bc85 5. /build/src/Interpreters/ProcessList.cpp:520: DB::QueryStatus::throwProperExceptionIfNeeded(unsigned long const&, unsigned long const&) @ 0x0000000014a4bbd9 6. /build/src/Interpreters/ProcessList.cpp:557: DB::QueryStatus::checkTimeLimit() @ 0x0000000014a4c2cd 7. /build/src/Processors/Executors/PipelineExecutor.cpp:206: DB::PipelineExecutor::finalizeExecution() @ 0x00000000169b13ba 8. /build/src/Processors/Executors/PipelineExecutor.cpp:153: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x00000000169b0584 9. /build/src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:se190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169bfeab 10. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc3d92 11. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fcca080 12. ? @ 0x00007fbc6213eac3 13. ? @ 0x00007fbc621d0850 2025.07.28 12:02:15.114512 [ 17255 ] {} TCPHandler: Code: 394. DB::Exception: Query was cancelled. (QUERY_WAS_CANCELLED), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000000a074fcb 4. /build/src/Interpreters/ProcessList.cpp:567: DB::QueryStatus::throwQueryWasCancelled() const @ 0x0000000014a4bc85 5. /build/src/Interpreters/ProcessList.cpp:520: DB::QueryStatus::throwProperExceptionIfNeeded(unsigned long const&, unsigned long const&) @ 0x0000000014a4bbd9 6. /build/src/Interpreters/ProcessList.cpp:557: DB::QueryStatus::checkTimeLimit() @ 0x0000000014a4c2cd 7. /build/src/Processors/Executors/PipelineExecutor.cpp:206: DB::PipelineExecutor::finalizeExecution() @ 0x00000000169b13ba 8. /build/src/Processors/Executors/PipelineExecutor.cpp:153: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x00000000169b0584 9. /build/src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:se190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169bfeab 10. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc3d92 11. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fcca080 12. ? @ 0x00007fbc6213eac3 13. ? @ 0x00007fbc621d0850 Job's origin stack trace: 0. /build/src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000000fc33b84 1. /build/src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000000fcc2ea7 2. /build/src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fcc535c 3. /build/src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000000fcc584d 4. /build/src/Common/ThreadPool.h:279: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x00000000169bf193 5. /build/src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x00000000169bf518 6. /build/src/Server/TCPHandler.cpp:1237: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x00000000168f1525 7. /build/src/Server/TCPHandler.cpp:678: DB::TCPHandler::runImpl() @ 0x00000000168e68e5 8. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 9. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 10. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 11. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 12. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 13. ? @ 0x00007fbc6213eac3 14. ? @ 0x00007fbc621d0850 2025.07.28 12:02:15.156168 [ 5951 ] {} 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. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception>&, String>(int, FormatStringHelperImpl>&>::type, std::type_identity::type>, std::basic_string_view>&, String&&) @ 0x000000001385a5eb 4. /build/src/Access/SettingsConstraints.cpp:376: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000013859b18 5. /build/src/Access/SettingsConstraints.cpp:300: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000013858faf 6. /build/src/Access/SettingsConstraints.cpp:209: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000013859223 7. /build/src/Interpreters/Context.cpp:2690: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000014436134 8. /build/src/Interpreters/Context.cpp:2729: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x000000001443662b 9. /build/src/Server/HTTPHandler.cpp:457: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000001686d165 10. /build/src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x0000000016870807 11. /build/src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x0000000016907e99 12. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 13. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 14. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 15. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 16. ? @ 0x00007fbc6213eac3 17. ? @ 0x00007fbc621d0850 (version 25.3.6.10636.altinitytest (altinity build)) 2025.07.28 12:02:15.218307 [ 4900 ] {dc7777a8-ddb6-48fa-bf2b-ff67abc95242} executeQuery: Code: 394. DB::Exception: Query was cancelled. (QUERY_WAS_CANCELLED) (version 25.3.6.10636.altinitytest (altinity build)) (from [::1]:44054) (comment: 02461_cancel_finish_race.sh) (query 1, line 1) (in query: KILL QUERY WHERE current_database = 'test_dtwle8fg' SYNC FORMAT Null), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000000a074fcb 4. /build/src/Interpreters/ProcessList.cpp:567: DB::QueryStatus::throwQueryWasCancelled() const @ 0x0000000014a4bc85 5. /build/src/Interpreters/ProcessList.cpp:520: DB::QueryStatus::throwProperExceptionIfNeeded(unsigned long const&, unsigned long const&) @ 0x0000000014a4bbd9 6. /build/src/Interpreters/ProcessList.cpp:531: DB::QueryStatus::addPipelineExecutor(DB::PipelineExecutor*) @ 0x0000000014a4bd9c 7. /build/src/Processors/Executors/PipelineExecutor.cpp:73: DB::PipelineExecutor::PipelineExecutor(std::shared_ptr, std::allocator>>>&, std::shared_ptr) @ 0x00000000169afe31 8. /build/contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x00000000169bef66 9. /build/src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x00000000169bf518 10. /build/src/Server/TCPHandler.cpp:1237: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x00000000168f1525 11. /build/src/Server/TCPHandler.cpp:678: DB::TCPHandler::runImpl() @ 0x00000000168e68e5 12. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 13. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 14. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 16. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 17. ? @ 0x00007fbc6213eac3 18. ? @ 0x00007fbc621d0850 2025.07.28 12:02:15.225840 [ 17371 ] {d2074b23-bdb6-4864-8e1d-e29b0e325c9e} executeQuery: Code: 394. DB::Exception: Query was cancelled. (QUERY_WAS_CANCELLED) (version 25.3.6.10636.altinitytest (altinity build)) (from [::1]:44046) (comment: 02461_cancel_finish_race.sh) (query 1, line 1) (in query: KILL QUERY WHERE current_database = 'test_dtwle8fg' SYNC FORMAT Null), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000000a074fcb 4. /build/src/Interpreters/ProcessList.cpp:567: DB::QueryStatus::throwQueryWasCancelled() const @ 0x0000000014a4bc85 5. /build/src/Interpreters/ProcessList.cpp:520: DB::QueryStatus::throwProperExceptionIfNeeded(unsigned long const&, unsigned long const&) @ 0x0000000014a4bbd9 6. /build/src/Interpreters/ProcessList.cpp:557: DB::QueryStatus::checkTimeLimit() @ 0x0000000014a4c2cd 7. /build/src/Processors/Executors/PipelineExecutor.cpp:206: DB::PipelineExecutor::finalizeExecution() @ 0x00000000169b13ba 8. /build/src/Processors/Executors/PipelineExecutor.cpp:153: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x00000000169b0584 9. /build/src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:se190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169bfeab 10. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc3d92 11. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fcca080 12. ? @ 0x00007fbc6213eac3 13. ? @ 0x00007fbc621d0850 2025.07.28 12:02:15.236376 [ 17371 ] {} TCPHandler: Code: 394. DB::Exception: Query was cancelled. (QUERY_WAS_CANCELLED), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000000a074fcb 4. /build/src/Interpreters/ProcessList.cpp:567: DB::QueryStatus::throwQueryWasCancelled() const @ 0x0000000014a4bc85 5. /build/src/Interpreters/ProcessList.cpp:520: DB::QueryStatus::throwProperExceptionIfNeeded(unsigned long const&, unsigned long const&) @ 0x0000000014a4bbd9 6. /build/src/Interpreters/ProcessList.cpp:557: DB::QueryStatus::checkTimeLimit() @ 0x0000000014a4c2cd 7. /build/src/Processors/Executors/PipelineExecutor.cpp:206: DB::PipelineExecutor::finalizeExecution() @ 0x00000000169b13ba 8. /build/src/Processors/Executors/PipelineExecutor.cpp:153: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x00000000169b0584 9. /build/src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:se190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169bfeab 10. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc3d92 11. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fcca080 12. ? @ 0x00007fbc6213eac3 13. ? @ 0x00007fbc621d0850 Job's origin stack trace: 0. /build/src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000000fc33b84 1. /build/src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000000fcc2ea7 2. /build/src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fcc535c 3. /build/src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000000fcc584d 4. /build/src/Common/ThreadPool.h:279: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x00000000169bf193 5. /build/src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x00000000169bf518 6. /build/src/Server/TCPHandler.cpp:1237: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x00000000168f1525 7. /build/src/Server/TCPHandler.cpp:678: DB::TCPHandler::runImpl() @ 0x00000000168e68e5 8. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 9. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 10. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 11. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 12. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 13. ? @ 0x00007fbc6213eac3 14. ? @ 0x00007fbc621d0850 2025.07.28 12:02:15.290003 [ 4900 ] {} TCPHandler: Code: 394. DB::Exception: Query was cancelled. (QUERY_WAS_CANCELLED), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000000a074fcb 4. /build/src/Interpreters/ProcessList.cpp:567: DB::QueryStatus::throwQueryWasCancelled() const @ 0x0000000014a4bc85 5. /build/src/Interpreters/ProcessList.cpp:520: DB::QueryStatus::throwProperExceptionIfNeeded(unsigned long const&, unsigned long const&) @ 0x0000000014a4bbd9 6. /build/src/Interpreters/ProcessList.cpp:531: DB::QueryStatus::addPipelineExecutor(DB::PipelineExecutor*) @ 0x0000000014a4bd9c 7. /build/src/Processors/Executors/PipelineExecutor.cpp:73: DB::PipelineExecutor::PipelineExecutor(std::shared_ptr, std::allocator>>>&, std::shared_ptr) @ 0x00000000169afe31 8. /build/contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x00000000169bef66 9. /build/src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x00000000169bf518 10. /build/src/Server/TCPHandler.cpp:1237: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x00000000168f1525 11. /build/src/Server/TCPHandler.cpp:678: DB::TCPHandler::runImpl() @ 0x00000000168e68e5 12. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 13. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 14. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 16. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 17. ? @ 0x00007fbc6213eac3 18. ? @ 0x00007fbc621d0850 2025.07.28 12:02:15.423387 [ 7625 ] {f28f6663-2c7f-4198-8ba9-c94ded5d1e8c} executeQuery: Code: 394. DB::Exception: Query was cancelled. (QUERY_WAS_CANCELLED) (version 25.3.6.10636.altinitytest (altinity build)) (from [::1]:44024) (comment: 02461_cancel_finish_race.sh) (query 1, line 1) (in query: KILL QUERY WHERE current_database = 'test_dtwle8fg' SYNC FORMAT Null), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000000a074fcb 4. /build/src/Interpreters/ProcessList.cpp:567: DB::QueryStatus::throwQueryWasCancelled() const @ 0x0000000014a4bc85 5. /build/src/Interpreters/ProcessList.cpp:520: DB::QueryStatus::throwProperExceptionIfNeeded(unsigned long const&, unsigned long const&) @ 0x0000000014a4bbd9 6. /build/src/Interpreters/ProcessList.cpp:557: DB::QueryStatus::checkTimeLimit() @ 0x0000000014a4c2cd 7. /build/src/Processors/Executors/PipelineExecutor.cpp:206: DB::PipelineExecutor::finalizeExecution() @ 0x00000000169b13ba 8. /build/src/Processors/Executors/PipelineExecutor.cpp:153: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x00000000169b0584 9. /build/src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:se190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169bfeab 10. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc3d92 11. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fcca080 12. ? @ 0x00007fbc6213eac3 13. ? @ 0x00007fbc621d0850 2025.07.28 12:02:15.435853 [ 7625 ] {} TCPHandler: Code: 394. DB::Exception: Query was cancelled. (QUERY_WAS_CANCELLED), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000000a074fcb 4. /build/src/Interpreters/ProcessList.cpp:567: DB::QueryStatus::throwQueryWasCancelled() const @ 0x0000000014a4bc85 5. /build/src/Interpreters/ProcessList.cpp:520: DB::QueryStatus::throwProperExceptionIfNeeded(unsigned long const&, unsigned long const&) @ 0x0000000014a4bbd9 6. /build/src/Interpreters/ProcessList.cpp:557: DB::QueryStatus::checkTimeLimit() @ 0x0000000014a4c2cd 7. /build/src/Processors/Executors/PipelineExecutor.cpp:206: DB::PipelineExecutor::finalizeExecution() @ 0x00000000169b13ba 8. /build/src/Processors/Executors/PipelineExecutor.cpp:153: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x00000000169b0584 9. /build/src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:se190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169bfeab 10. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc3d92 11. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fcca080 12. ? @ 0x00007fbc6213eac3 13. ? @ 0x00007fbc621d0850 Job's origin stack trace: 0. /build/src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000000fc33b84 1. /build/src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000000fcc2ea7 2. /build/src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fcc535c 3. /build/src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000000fcc584d 4. /build/src/Common/ThreadPool.h:279: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x00000000169bf193 5. /build/src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x00000000169bf518 6. /build/src/Server/TCPHandler.cpp:1237: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x00000000168f1525 7. /build/src/Server/TCPHandler.cpp:678: DB::TCPHandler::runImpl() @ 0x00000000168e68e5 8. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 9. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 10. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 11. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 12. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 13. ? @ 0x00007fbc6213eac3 14. ? @ 0x00007fbc621d0850 2025.07.28 12:02:15.676073 [ 11826 ] {7cedf6f2-8ddc-485d-a392-76e99f4ff69b} executeQuery: Code: 394. DB::Exception: Query was cancelled. (QUERY_WAS_CANCELLED) (version 25.3.6.10636.altinitytest (altinity build)) (from [::1]:44152) (comment: 02461_cancel_finish_race.sh) (query 1, line 1) (in query: KILL QUERY WHERE current_database = 'test_dtwle8fg' SYNC FORMAT Null), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000000a074fcb 4. /build/src/Interpreters/ProcessList.cpp:567: DB::QueryStatus::throwQueryWasCancelled() const @ 0x0000000014a4bc85 5. /build/src/Interpreters/ProcessList.cpp:520: DB::QueryStatus::throwProperExceptionIfNeeded(unsigned long const&, unsigned long const&) @ 0x0000000014a4bbd9 6. /build/src/Interpreters/ProcessList.cpp:557: DB::QueryStatus::checkTimeLimit() @ 0x0000000014a4c2cd 7. /build/src/Processors/Executors/PipelineExecutor.cpp:206: DB::PipelineExecutor::finalizeExecution() @ 0x00000000169b13ba 8. /build/src/Processors/Executors/PipelineExecutor.cpp:153: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x00000000169b0584 9. /build/src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:se190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169bfeab 10. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc3d92 11. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fcca080 12. ? @ 0x00007fbc6213eac3 13. ? @ 0x00007fbc621d0850 2025.07.28 12:02:15.687218 [ 11826 ] {} TCPHandler: Code: 394. DB::Exception: Query was cancelled. (QUERY_WAS_CANCELLED), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000000a074fcb 4. /build/src/Interpreters/ProcessList.cpp:567: DB::QueryStatus::throwQueryWasCancelled() const @ 0x0000000014a4bc85 5. /build/src/Interpreters/ProcessList.cpp:520: DB::QueryStatus::throwProperExceptionIfNeeded(unsigned long const&, unsigned long const&) @ 0x0000000014a4bbd9 6. /build/src/Interpreters/ProcessList.cpp:557: DB::QueryStatus::checkTimeLimit() @ 0x0000000014a4c2cd 7. /build/src/Processors/Executors/PipelineExecutor.cpp:206: DB::PipelineExecutor::finalizeExecution() @ 0x00000000169b13ba 8. /build/src/Processors/Executors/PipelineExecutor.cpp:153: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x00000000169b0584 9. /build/src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:se190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169bfeab 10. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc3d92 11. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fcca080 12. ? @ 0x00007fbc6213eac3 13. ? @ 0x00007fbc621d0850 Job's origin stack trace: 0. /build/src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000000fc33b84 1. /build/src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000000fcc2ea7 2. /build/src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fcc535c 3. /build/src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000000fcc584d 4. /build/src/Common/ThreadPool.h:279: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x00000000169bf193 5. /build/src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x00000000169bf518 6. /build/src/Server/TCPHandler.cpp:1237: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x00000000168f1525 7. /build/src/Server/TCPHandler.cpp:678: DB::TCPHandler::runImpl() @ 0x00000000168e68e5 8. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 9. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 10. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 11. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 12. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 13. ? @ 0x00007fbc6213eac3 14. ? @ 0x00007fbc621d0850 2025.07.28 12:02:15.694791 [ 17232 ] {5f1fcc30-e7ef-44c8-a187-5f8fb129ba2d} executeQuery: Code: 394. DB::Exception: Query was cancelled. (QUERY_WAS_CANCELLED) (version 25.3.6.10636.altinitytest (altinity build)) (from [::1]:44188) (comment: 02461_cancel_finish_race.sh) (query 1, line 1) (in query: KILL QUERY WHERE current_database = 'test_dtwle8fg' SYNC FORMAT Null), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000000a074fcb 4. /build/src/Interpreters/ProcessList.cpp:567: DB::QueryStatus::throwQueryWasCancelled() const @ 0x0000000014a4bc85 5. /build/src/Interpreters/ProcessList.cpp:520: DB::QueryStatus::throwProperExceptionIfNeeded(unsigned long const&, unsigned long const&) @ 0x0000000014a4bbd9 6. /build/src/Interpreters/ProcessList.cpp:531: DB::QueryStatus::addPipelineExecutor(DB::PipelineExecutor*) @ 0x0000000014a4bd9c 7. /build/src/Processors/Executors/PipelineExecutor.cpp:73: DB::PipelineExecutor::PipelineExecutor(std::shared_ptr, std::allocator>>>&, std::shared_ptr) @ 0x00000000169afe31 8. /build/contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x00000000169bef66 9. /build/src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x00000000169bf518 10. /build/src/Server/TCPHandler.cpp:1237: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x00000000168f1525 11. /build/src/Server/TCPHandler.cpp:678: DB::TCPHandler::runImpl() @ 0x00000000168e68e5 12. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 13. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 14. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 16. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 17. ? @ 0x00007fbc6213eac3 18. ? @ 0x00007fbc621d0850 2025.07.28 12:02:15.798161 [ 17232 ] {} TCPHandler: Code: 394. DB::Exception: Query was cancelled. (QUERY_WAS_CANCELLED), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000000a074fcb 4. /build/src/Interpreters/ProcessList.cpp:567: DB::QueryStatus::throwQueryWasCancelled() const @ 0x0000000014a4bc85 5. /build/src/Interpreters/ProcessList.cpp:520: DB::QueryStatus::throwProperExceptionIfNeeded(unsigned long const&, unsigned long const&) @ 0x0000000014a4bbd9 6. /build/src/Interpreters/ProcessList.cpp:531: DB::QueryStatus::addPipelineExecutor(DB::PipelineExecutor*) @ 0x0000000014a4bd9c 7. /build/src/Processors/Executors/PipelineExecutor.cpp:73: DB::PipelineExecutor::PipelineExecutor(std::shared_ptr, std::allocator>>>&, std::shared_ptr) @ 0x00000000169afe31 8. /build/contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x00000000169bef66 9. /build/src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x00000000169bf518 10. /build/src/Server/TCPHandler.cpp:1237: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x00000000168f1525 11. /build/src/Server/TCPHandler.cpp:678: DB::TCPHandler::runImpl() @ 0x00000000168e68e5 12. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 13. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 14. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 16. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 17. ? @ 0x00007fbc6213eac3 18. ? @ 0x00007fbc621d0850 2025.07.28 12:02:15.807339 [ 17256 ] {aaa99ac8-da55-478e-b18f-af57c4d71c05} executeQuery: Code: 394. DB::Exception: Query was cancelled. (QUERY_WAS_CANCELLED) (version 25.3.6.10636.altinitytest (altinity build)) (from [::1]:44176) (comment: 02461_cancel_finish_race.sh) (query 1, line 1) (in query: KILL QUERY WHERE current_database = 'test_dtwle8fg' SYNC FORMAT Null), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000000a074fcb 4. /build/src/Interpreters/ProcessList.cpp:567: DB::QueryStatus::throwQueryWasCancelled() const @ 0x0000000014a4bc85 5. /build/src/Interpreters/ProcessList.cpp:520: DB::QueryStatus::throwProperExceptionIfNeeded(unsigned long const&, unsigned long const&) @ 0x0000000014a4bbd9 6. /build/src/Interpreters/ProcessList.cpp:557: DB::QueryStatus::checkTimeLimit() @ 0x0000000014a4c2cd 7. /build/src/Processors/Executors/PipelineExecutor.cpp:206: DB::PipelineExecutor::finalizeExecution() @ 0x00000000169b13ba 8. /build/src/Processors/Executors/PipelineExecutor.cpp:153: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x00000000169b0584 9. /build/src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:se190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169bfeab 10. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc3d92 11. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fcca080 12. ? @ 0x00007fbc6213eac3 13. ? @ 0x00007fbc621d0850 2025.07.28 12:02:15.823986 [ 3967 ] {} test_13.rmt2 (7f9b740d-015c-470e-8cc6-8ba33be0dc63): auto DB::StorageReplicatedMergeTree::processQueueEntry(ReplicatedMergeTreeQueue::SelectedEntryPtr)::(anonymous class)::operator()(LogEntryPtr &) const: Code: 86. DB::HTTPException: Received error from remote server http://146b4357c08d:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Ftest%2F01165%2Ftest_13%2Frmt%2Freplicas%2F1&part=20250728_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.6.10636.altinitytest (altinity build)) '. (RECEIVED_ERROR_FROM_REMOTE_IO_SERVER), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.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 const&, int&&, String const&, unsigned long&&, String const&) @ 0x000000000feda8d9 4. /build/src/IO/HTTPCommon.cpp:104: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x000000000feda6e2 5. /build/src/IO/HTTPCommon.cpp:93: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x000000000feda537 6. /build/src/IO/ReadWriteBufferFromHTTP.cpp:277: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x000000001184a4c4 7. /build/src/IO/ReadWriteBufferFromHTTP.cpp:285: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x000000001184a615 8. /build/src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x000000001184ae59 9. /build/src/IO/ReadWriteBufferFromHTTP.cpp:472: void std::__function::__policy_invoker::__call_impl[abi:se190107]>(std::__function::__policy_storage const*) @ 0x000000001184cedd 10. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001184858b 11. /build/src/IO/ReadWriteBufferFromHTTP.cpp:465: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x000000001184bf0b 12. /build/src/IO/ReadBuffer.h:60: DB::ReadBuffer::next() @ 0x000000000a148c7b 13. /build/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) @ 0x0000000011849fb2 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]>&)>&, 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&) @ 0x0000000011841980 15. /build/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) @ 0x000000001621208e 16. /build/src/Storages/StorageReplicatedMergeTree.cpp:5228: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl[abi:se190107] const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000015f9a5fe 17. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000015ed8bfd 18. /build/src/Storages/StorageReplicatedMergeTree.cpp:2514: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x0000000015ec9aab 19. /build/src/Storages/StorageReplicatedMergeTree.cpp:2349: DB::StorageReplicatedMergeTree::executeLogEntry(DB::ReplicatedMergeTreeLogEntry&) @ 0x0000000015eba91b 20. /build/src/Storages/StorageReplicatedMergeTree.cpp:3876: bool std::__function::__policy_invoker&)>::__call_impl[abi:se190107])::$_1, bool (std::shared_ptr&)>>(std::__function::__policy_storage const*, std::shared_ptr&) @ 0x0000000015f9837e 21. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000165d6fc3 22. /build/src/Storages/StorageReplicatedMergeTree.cpp:3872: DB::StorageReplicatedMergeTree::processQueueEntry(std::shared_ptr) @ 0x0000000015efc18a 23. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001624c1b2 24. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000162f9c70 25. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x00000000162fa55a 26. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc6653 27. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000000fccc4c3 28. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc3d92 29. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fcca080 30. ? @ 0x00007fbc6213eac3 31. ? @ 0x00007fbc621d0850 (version 25.3.6.10636.altinitytest (altinity build)) 2025.07.28 12:02:15.828423 [ 17256 ] {} TCPHandler: Code: 394. DB::Exception: Query was cancelled. (QUERY_WAS_CANCELLED), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000000a074fcb 4. /build/src/Interpreters/ProcessList.cpp:567: DB::QueryStatus::throwQueryWasCancelled() const @ 0x0000000014a4bc85 5. /build/src/Interpreters/ProcessList.cpp:520: DB::QueryStatus::throwProperExceptionIfNeeded(unsigned long const&, unsigned long const&) @ 0x0000000014a4bbd9 6. /build/src/Interpreters/ProcessList.cpp:557: DB::QueryStatus::checkTimeLimit() @ 0x0000000014a4c2cd 7. /build/src/Processors/Executors/PipelineExecutor.cpp:206: DB::PipelineExecutor::finalizeExecution() @ 0x00000000169b13ba 8. /build/src/Processors/Executors/PipelineExecutor.cpp:153: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x00000000169b0584 9. /build/src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:se190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169bfeab 10. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc3d92 11. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fcca080 12. ? @ 0x00007fbc6213eac3 13. ? @ 0x00007fbc621d0850 Job's origin stack trace: 0. /build/src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000000fc33b84 1. /build/src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000000fcc2ea7 2. /build/src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fcc535c 3. /build/src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000000fcc584d 4. /build/src/Common/ThreadPool.h:279: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x00000000169bf193 5. /build/src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x00000000169bf518 6. /build/src/Server/TCPHandler.cpp:1237: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x00000000168f1525 7. /build/src/Server/TCPHandler.cpp:678: DB::TCPHandler::runImpl() @ 0x00000000168e68e5 8. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 9. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 10. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 11. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 12. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 13. ? @ 0x00007fbc6213eac3 14. ? @ 0x00007fbc621d0850 2025.07.28 12:02:15.836910 [ 62325 ] {648ce53a-55ac-47e2-81d6-4a1ab01c85f1} executeQuery: Code: 394. DB::Exception: Query was cancelled. (QUERY_WAS_CANCELLED) (version 25.3.6.10636.altinitytest (altinity build)) (from [::1]:44230) (comment: 02461_cancel_finish_race.sh) (query 1, line 1) (in query: KILL QUERY WHERE current_database = 'test_dtwle8fg' SYNC FORMAT Null), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000000a074fcb 4. /build/src/Interpreters/ProcessList.cpp:567: DB::QueryStatus::throwQueryWasCancelled() const @ 0x0000000014a4bc85 5. /build/src/Interpreters/ProcessList.cpp:520: DB::QueryStatus::throwProperExceptionIfNeeded(unsigned long const&, unsigned long const&) @ 0x0000000014a4bbd9 6. /build/src/Interpreters/ProcessList.cpp:557: DB::QueryStatus::checkTimeLimit() @ 0x0000000014a4c2cd 7. /build/src/Processors/Executors/PipelineExecutor.cpp:206: DB::PipelineExecutor::finalizeExecution() @ 0x00000000169b13ba 8. /build/src/Processors/Executors/PipelineExecutor.cpp:153: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x00000000169b0584 9. /build/src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:se190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169bfeab 10. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc3d92 11. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fcca080 12. ? @ 0x00007fbc6213eac3 13. ? @ 0x00007fbc621d0850 2025.07.28 12:02:15.836859 [ 4446 ] {} TCPHandler: Code: 394. DB::Exception: Query was cancelled. (QUERY_WAS_CANCELLED), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000000a074fcb 4. /build/src/Interpreters/ProcessList.cpp:567: DB::QueryStatus::throwQueryWasCancelled() const @ 0x0000000014a4bc85 5. /build/src/Interpreters/ProcessList.cpp:520: DB::QueryStatus::throwProperExceptionIfNeeded(unsigned long const&, unsigned long const&) @ 0x0000000014a4bbd9 6. /build/src/Interpreters/ProcessList.cpp:557: DB::QueryStatus::checkTimeLimit() @ 0x0000000014a4c2cd 7. /build/src/Processors/Executors/PipelineExecutor.cpp:206: DB::PipelineExecutor::finalizeExecution() @ 0x00000000169b13ba 8. /build/src/Processors/Executors/PipelineExecutor.cpp:181: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x00000000169b1726 9. /build/src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x00000000169c081c 10. /build/src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x00000000169c0978 11. /build/src/Interpreters/InterpreterKillQueryQuery.cpp:439: DB::InterpreterKillQueryQuery::getSelectResult(String const&, String const&) @ 0x0000000014cf0f04 12. /build/src/Interpreters/InterpreterKillQueryQuery.cpp:222: DB::InterpreterKillQueryQuery::execute() @ 0x0000000014cebde2 13. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88dc9 14. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 15. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 16. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 17. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 18. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 19. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 20. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 21. ? @ 0x00007fbc6213eac3 22. ? @ 0x00007fbc621d0850 2025.07.28 12:02:15.839707 [ 17255 ] {9f53920e-877c-4e6c-8db4-dbe770045098} executeQuery: Code: 394. DB::Exception: Query was cancelled. (QUERY_WAS_CANCELLED) (version 25.3.6.10636.altinitytest (altinity build)) (from [::1]:44228) (comment: 02461_cancel_finish_race.sh) (query 1, line 1) (in query: KILL QUERY WHERE current_database = 'test_dtwle8fg' SYNC FORMAT Null), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000000a074fcb 4. /build/src/Interpreters/ProcessList.cpp:567: DB::QueryStatus::throwQueryWasCancelled() const @ 0x0000000014a4bc85 5. /build/src/Interpreters/ProcessList.cpp:520: DB::QueryStatus::throwProperExceptionIfNeeded(unsigned long const&, unsigned long const&) @ 0x0000000014a4bbd9 6. /build/src/Interpreters/ProcessList.cpp:557: DB::QueryStatus::checkTimeLimit() @ 0x0000000014a4c2cd 7. /build/src/Processors/Executors/PipelineExecutor.cpp:206: DB::PipelineExecutor::finalizeExecution() @ 0x00000000169b13ba 8. /build/src/Processors/Executors/PipelineExecutor.cpp:153: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x00000000169b0584 9. /build/src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:se190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169bfeab 10. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc3d92 11. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fcca080 12. ? @ 0x00007fbc6213eac3 13. ? @ 0x00007fbc621d0850 2025.07.28 12:02:15.849540 [ 17255 ] {} TCPHandler: Code: 394. DB::Exception: Query was cancelled. (QUERY_WAS_CANCELLED), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000000a074fcb 4. /build/src/Interpreters/ProcessList.cpp:567: DB::QueryStatus::throwQueryWasCancelled() const @ 0x0000000014a4bc85 5. /build/src/Interpreters/ProcessList.cpp:520: DB::QueryStatus::throwProperExceptionIfNeeded(unsigned long const&, unsigned long const&) @ 0x0000000014a4bbd9 6. /build/src/Interpreters/ProcessList.cpp:557: DB::QueryStatus::checkTimeLimit() @ 0x0000000014a4c2cd 7. /build/src/Processors/Executors/PipelineExecutor.cpp:206: DB::PipelineExecutor::finalizeExecution() @ 0x00000000169b13ba 8. /build/src/Processors/Executors/PipelineExecutor.cpp:153: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x00000000169b0584 9. /build/src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:se190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169bfeab 10. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc3d92 11. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fcca080 12. ? @ 0x00007fbc6213eac3 13. ? @ 0x00007fbc621d0850 Job's origin stack trace: 0. /build/src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000000fc33b84 1. /build/src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000000fcc2ea7 2. /build/src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fcc535c 3. /build/src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000000fcc584d 4. /build/src/Common/ThreadPool.h:279: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x00000000169bf193 5. /build/src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x00000000169bf518 6. /build/src/Server/TCPHandler.cpp:1237: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x00000000168f1525 7. /build/src/Server/TCPHandler.cpp:678: DB::TCPHandler::runImpl() @ 0x00000000168e68e5 8. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 9. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 10. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 11. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 12. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 13. ? @ 0x00007fbc6213eac3 14. ? @ 0x00007fbc621d0850 2025.07.28 12:02:15.856567 [ 62325 ] {} TCPHandler: Code: 394. DB::Exception: Query was cancelled. (QUERY_WAS_CANCELLED), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000000a074fcb 4. /build/src/Interpreters/ProcessList.cpp:567: DB::QueryStatus::throwQueryWasCancelled() const @ 0x0000000014a4bc85 5. /build/src/Interpreters/ProcessList.cpp:520: DB::QueryStatus::throwProperExceptionIfNeeded(unsigned long const&, unsigned long const&) @ 0x0000000014a4bbd9 6. /build/src/Interpreters/ProcessList.cpp:557: DB::QueryStatus::checkTimeLimit() @ 0x0000000014a4c2cd 7. /build/src/Processors/Executors/PipelineExecutor.cpp:206: DB::PipelineExecutor::finalizeExecution() @ 0x00000000169b13ba 8. /build/src/Processors/Executors/PipelineExecutor.cpp:153: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x00000000169b0584 9. /build/src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:se190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169bfeab 10. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc3d92 11. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fcca080 12. ? @ 0x00007fbc6213eac3 13. ? @ 0x00007fbc621d0850 Job's origin stack trace: 0. /build/src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000000fc33b84 1. /build/src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000000fcc2ea7 2. /build/src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fcc535c 3. /build/src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000000fcc584d 4. /build/src/Common/ThreadPool.h:279: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x00000000169bf193 5. /build/src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x00000000169bf518 6. /build/src/Server/TCPHandler.cpp:1237: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x00000000168f1525 7. /build/src/Server/TCPHandler.cpp:678: DB::TCPHandler::runImpl() @ 0x00000000168e68e5 8. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 9. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 10. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 11. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 12. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 13. ? @ 0x00007fbc6213eac3 14. ? @ 0x00007fbc621d0850 2025.07.28 12:02:16.068904 [ 17243 ] {} TCPHandler: Code: 394. DB::Exception: Query was cancelled. (QUERY_WAS_CANCELLED), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000000a074fcb 4. /build/src/Interpreters/ProcessList.cpp:567: DB::QueryStatus::throwQueryWasCancelled() const @ 0x0000000014a4bc85 5. /build/src/Interpreters/ProcessList.cpp:520: DB::QueryStatus::throwProperExceptionIfNeeded(unsigned long const&, unsigned long const&) @ 0x0000000014a4bbd9 6. /build/src/Interpreters/ProcessList.cpp:557: DB::QueryStatus::checkTimeLimit() @ 0x0000000014a4c2cd 7. /build/src/Processors/Executors/PipelineExecutor.cpp:206: DB::PipelineExecutor::finalizeExecution() @ 0x00000000169b13ba 8. /build/src/Processors/Executors/PipelineExecutor.cpp:181: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x00000000169b1726 9. /build/src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x00000000169c081c 10. /build/src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x00000000169c0978 11. /build/src/Interpreters/InterpreterKillQueryQuery.cpp:442: DB::InterpreterKillQueryQuery::getSelectResult(String const&, String const&) @ 0x0000000014cf0f6b 12. /build/src/Interpreters/InterpreterKillQueryQuery.cpp:222: DB::InterpreterKillQueryQuery::execute() @ 0x0000000014cebde2 13. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88dc9 14. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 15. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 16. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 17. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 18. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 19. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 20. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 21. ? @ 0x00007fbc6213eac3 22. ? @ 0x00007fbc621d0850 2025.07.28 12:02:16.083555 [ 7625 ] {efec7b05-d58a-42e2-8dc0-85003b0ea1f8} executeQuery: Code: 394. DB::Exception: Query was cancelled. (QUERY_WAS_CANCELLED) (version 25.3.6.10636.altinitytest (altinity build)) (from [::1]:44338) (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. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000000a074fcb 4. /build/src/Interpreters/ProcessList.cpp:567: DB::QueryStatus::throwQueryWasCancelled() const @ 0x0000000014a4bc85 5. /build/src/Interpreters/ProcessList.cpp:520: DB::QueryStatus::throwProperExceptionIfNeeded(unsigned long const&, unsigned long const&) @ 0x0000000014a4bbd9 6. /build/src/Interpreters/ProcessList.cpp:557: DB::QueryStatus::checkTimeLimit() @ 0x0000000014a4c2cd 7. /build/src/Processors/Executors/PipelineExecutor.cpp:206: DB::PipelineExecutor::finalizeExecution() @ 0x00000000169b13ba 8. /build/src/Processors/Executors/PipelineExecutor.cpp:153: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x00000000169b0584 9. /build/src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:se190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169bfeab 10. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc3d92 11. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fcca080 12. ? @ 0x00007fbc6213eac3 13. ? @ 0x00007fbc621d0850 2025.07.28 12:02:16.101097 [ 7625 ] {} TCPHandler: Code: 394. DB::Exception: Query was cancelled. (QUERY_WAS_CANCELLED), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000000a074fcb 4. /build/src/Interpreters/ProcessList.cpp:567: DB::QueryStatus::throwQueryWasCancelled() const @ 0x0000000014a4bc85 5. /build/src/Interpreters/ProcessList.cpp:520: DB::QueryStatus::throwProperExceptionIfNeeded(unsigned long const&, unsigned long const&) @ 0x0000000014a4bbd9 6. /build/src/Interpreters/ProcessList.cpp:557: DB::QueryStatus::checkTimeLimit() @ 0x0000000014a4c2cd 7. /build/src/Processors/Executors/PipelineExecutor.cpp:206: DB::PipelineExecutor::finalizeExecution() @ 0x00000000169b13ba 8. /build/src/Processors/Executors/PipelineExecutor.cpp:153: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x00000000169b0584 9. /build/src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:se190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169bfeab 10. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc3d92 11. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fcca080 12. ? @ 0x00007fbc6213eac3 13. ? @ 0x00007fbc621d0850 Job's origin stack trace: 0. /build/src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000000fc33b84 1. /build/src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000000fcc2ea7 2. /build/src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fcc535c 3. /build/src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000000fcc584d 4. /build/src/Common/ThreadPool.h:279: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x00000000169bf193 5. /build/src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x00000000169bf518 6. /build/src/Server/TCPHandler.cpp:1237: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x00000000168f1525 7. /build/src/Server/TCPHandler.cpp:678: DB::TCPHandler::runImpl() @ 0x00000000168e68e5 8. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 9. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 10. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 11. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 12. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 13. ? @ 0x00007fbc6213eac3 14. ? @ 0x00007fbc621d0850 2025.07.28 12:02:16.143798 [ 4900 ] {6329786d-35a3-41a1-8fcb-fc2b44fa5b75} executeQuery: Code: 394. DB::Exception: Query was cancelled. (QUERY_WAS_CANCELLED) (version 25.3.6.10636.altinitytest (altinity build)) (from [::1]:44250) (comment: 02461_cancel_finish_race.sh) (query 1, line 1) (in query: KILL QUERY WHERE current_database = 'test_dtwle8fg' SYNC FORMAT Null), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000000a074fcb 4. /build/src/Interpreters/ProcessList.cpp:567: DB::QueryStatus::throwQueryWasCancelled() const @ 0x0000000014a4bc85 5. /build/src/Interpreters/ProcessList.cpp:520: DB::QueryStatus::throwProperExceptionIfNeeded(unsigned long const&, unsigned long const&) @ 0x0000000014a4bbd9 6. /build/src/Interpreters/ProcessList.cpp:557: DB::QueryStatus::checkTimeLimit() @ 0x0000000014a4c2cd 7. /build/src/Processors/Executors/PipelineExecutor.cpp:206: DB::PipelineExecutor::finalizeExecution() @ 0x00000000169b13ba 8. /build/src/Processors/Executors/PipelineExecutor.cpp:153: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x00000000169b0584 9. /build/src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:se190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169bfeab 10. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc3d92 11. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fcca080 12. ? @ 0x00007fbc6213eac3 13. ? @ 0x00007fbc621d0850 2025.07.28 12:02:16.220675 [ 4900 ] {} TCPHandler: Code: 394. DB::Exception: Query was cancelled. (QUERY_WAS_CANCELLED), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000000a074fcb 4. /build/src/Interpreters/ProcessList.cpp:567: DB::QueryStatus::throwQueryWasCancelled() const @ 0x0000000014a4bc85 5. /build/src/Interpreters/ProcessList.cpp:520: DB::QueryStatus::throwProperExceptionIfNeeded(unsigned long const&, unsigned long const&) @ 0x0000000014a4bbd9 6. /build/src/Interpreters/ProcessList.cpp:557: DB::QueryStatus::checkTimeLimit() @ 0x0000000014a4c2cd 7. /build/src/Processors/Executors/PipelineExecutor.cpp:206: DB::PipelineExecutor::finalizeExecution() @ 0x00000000169b13ba 8. /build/src/Processors/Executors/PipelineExecutor.cpp:153: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x00000000169b0584 9. /build/src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:se190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169bfeab 10. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc3d92 11. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fcca080 12. ? @ 0x00007fbc6213eac3 13. ? @ 0x00007fbc621d0850 Job's origin stack trace: 0. /build/src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000000fc33b84 1. /build/src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000000fcc2ea7 2. /build/src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fcc535c 3. /build/src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000000fcc584d 4. /build/src/Common/ThreadPool.h:279: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x00000000169bf193 5. /build/src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x00000000169bf518 6. /build/src/Server/TCPHandler.cpp:1237: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x00000000168f1525 7. /build/src/Server/TCPHandler.cpp:678: DB::TCPHandler::runImpl() @ 0x00000000168e68e5 8. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 9. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 10. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 11. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 12. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 13. ? @ 0x00007fbc6213eac3 14. ? @ 0x00007fbc621d0850 2025.07.28 12:02:16.346172 [ 62075 ] {a3a27315-7aab-4f7d-8571-856930c8e8a8} executeQuery: Code: 394. DB::Exception: Query was cancelled. (QUERY_WAS_CANCELLED) (version 25.3.6.10636.altinitytest (altinity build)) (from [::1]:44386) (comment: 02461_cancel_finish_race.sh) (query 1, line 1) (in query: KILL QUERY WHERE current_database = 'test_dtwle8fg' SYNC FORMAT Null), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000000a074fcb 4. /build/src/Interpreters/ProcessList.cpp:567: DB::QueryStatus::throwQueryWasCancelled() const @ 0x0000000014a4bc85 5. /build/src/Interpreters/ProcessList.cpp:520: DB::QueryStatus::throwProperExceptionIfNeeded(unsigned long const&, unsigned long const&) @ 0x0000000014a4bbd9 6. /build/src/Interpreters/ProcessList.cpp:531: DB::QueryStatus::addPipelineExecutor(DB::PipelineExecutor*) @ 0x0000000014a4bd9c 7. /build/src/Processors/Executors/PipelineExecutor.cpp:73: DB::PipelineExecutor::PipelineExecutor(std::shared_ptr, std::allocator>>>&, std::shared_ptr) @ 0x00000000169afe31 8. /build/contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x00000000169bef66 9. /build/src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x00000000169bf518 10. /build/src/Server/TCPHandler.cpp:1237: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x00000000168f1525 11. /build/src/Server/TCPHandler.cpp:678: DB::TCPHandler::runImpl() @ 0x00000000168e68e5 12. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 13. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 14. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 16. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 17. ? @ 0x00007fbc6213eac3 18. ? @ 0x00007fbc621d0850 2025.07.28 12:02:16.363932 [ 62075 ] {} TCPHandler: Code: 394. DB::Exception: Query was cancelled. (QUERY_WAS_CANCELLED), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000000a074fcb 4. /build/src/Interpreters/ProcessList.cpp:567: DB::QueryStatus::throwQueryWasCancelled() const @ 0x0000000014a4bc85 5. /build/src/Interpreters/ProcessList.cpp:520: DB::QueryStatus::throwProperExceptionIfNeeded(unsigned long const&, unsigned long const&) @ 0x0000000014a4bbd9 6. /build/src/Interpreters/ProcessList.cpp:531: DB::QueryStatus::addPipelineExecutor(DB::PipelineExecutor*) @ 0x0000000014a4bd9c 7. /build/src/Processors/Executors/PipelineExecutor.cpp:73: DB::PipelineExecutor::PipelineExecutor(std::shared_ptr, std::allocator>>>&, std::shared_ptr) @ 0x00000000169afe31 8. /build/contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x00000000169bef66 9. /build/src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x00000000169bf518 10. /build/src/Server/TCPHandler.cpp:1237: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x00000000168f1525 11. /build/src/Server/TCPHandler.cpp:678: DB::TCPHandler::runImpl() @ 0x00000000168e68e5 12. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 13. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 14. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 16. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 17. ? @ 0x00007fbc6213eac3 18. ? @ 0x00007fbc621d0850 2025.07.28 12:02:16.370553 [ 11826 ] {} TCPHandler: Code: 394. DB::Exception: Query '7da7358d-f2f4-47bb-9bd8-c98903736463' is killed in pending state. (QUERY_WAS_CANCELLED), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x000000000a06b56b 4. /build/src/Interpreters/executeQuery.cpp:1522: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c8a4ef 5. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 6. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 7. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 8. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 9. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 10. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 11. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 12. ? @ 0x00007fbc6213eac3 13. ? @ 0x00007fbc621d0850 2025.07.28 12:02:16.481569 [ 4446 ] {cc99b7f1-5e5a-44a0-8727-574e9defd0a9} executeQuery: Code: 394. DB::Exception: Query was cancelled. (QUERY_WAS_CANCELLED) (version 25.3.6.10636.altinitytest (altinity build)) (from [::1]:44420) (comment: 02461_cancel_finish_race.sh) (query 1, line 1) (in query: KILL QUERY WHERE current_database = 'test_dtwle8fg' SYNC FORMAT Null), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000000a074fcb 4. /build/src/Interpreters/ProcessList.cpp:567: DB::QueryStatus::throwQueryWasCancelled() const @ 0x0000000014a4bc85 5. /build/src/Interpreters/ProcessList.cpp:520: DB::QueryStatus::throwProperExceptionIfNeeded(unsigned long const&, unsigned long const&) @ 0x0000000014a4bbd9 6. /build/src/Interpreters/ProcessList.cpp:557: DB::QueryStatus::checkTimeLimit() @ 0x0000000014a4c2cd 7. /build/src/Processors/Executors/PipelineExecutor.cpp:206: DB::PipelineExecutor::finalizeExecution() @ 0x00000000169b13ba 8. /build/src/Processors/Executors/PipelineExecutor.cpp:153: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x00000000169b0584 9. /build/src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:se190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169bfeab 10. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc3d92 11. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fcca080 12. ? @ 0x00007fbc6213eac3 13. ? @ 0x00007fbc621d0850 2025.07.28 12:02:16.488509 [ 62053 ] {119f1edd-c738-4a7e-b93b-57ea08e5ce73} executeQuery: Code: 394. DB::Exception: Query was cancelled. (QUERY_WAS_CANCELLED) (version 25.3.6.10636.altinitytest (altinity build)) (from [::1]:44396) (comment: 02461_cancel_finish_race.sh) (query 1, line 1) (in query: KILL QUERY WHERE current_database = 'test_dtwle8fg' SYNC FORMAT Null), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000000a074fcb 4. /build/src/Interpreters/ProcessList.cpp:567: DB::QueryStatus::throwQueryWasCancelled() const @ 0x0000000014a4bc85 5. /build/src/Interpreters/ProcessList.cpp:520: DB::QueryStatus::throwProperExceptionIfNeeded(unsigned long const&, unsigned long const&) @ 0x0000000014a4bbd9 6. /build/src/Interpreters/ProcessList.cpp:557: DB::QueryStatus::checkTimeLimit() @ 0x0000000014a4c2cd 7. /build/src/Processors/Executors/PipelineExecutor.cpp:206: DB::PipelineExecutor::finalizeExecution() @ 0x00000000169b13ba 8. /build/src/Processors/Executors/PipelineExecutor.cpp:153: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x00000000169b0584 9. /build/src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:se190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169bfeab 10. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc3d92 11. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fcca080 12. ? @ 0x00007fbc6213eac3 13. ? @ 0x00007fbc621d0850 2025.07.28 12:02:16.495615 [ 17256 ] {} TCPHandler: Code: 394. DB::Exception: Query was cancelled. (QUERY_WAS_CANCELLED), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000000a074fcb 4. /build/src/Interpreters/ProcessList.cpp:567: DB::QueryStatus::throwQueryWasCancelled() const @ 0x0000000014a4bc85 5. /build/src/Interpreters/ProcessList.cpp:520: DB::QueryStatus::throwProperExceptionIfNeeded(unsigned long const&, unsigned long const&) @ 0x0000000014a4bbd9 6. /build/src/Interpreters/ProcessList.cpp:557: DB::QueryStatus::checkTimeLimit() @ 0x0000000014a4c2cd 7. /build/src/Processors/Executors/PipelineExecutor.cpp:206: DB::PipelineExecutor::finalizeExecution() @ 0x00000000169b13ba 8. /build/src/Processors/Executors/PipelineExecutor.cpp:181: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x00000000169b1726 9. /build/src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x00000000169c081c 10. /build/src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x00000000169c0978 11. /build/src/Interpreters/InterpreterKillQueryQuery.cpp:442: DB::InterpreterKillQueryQuery::getSelectResult(String const&, String const&) @ 0x0000000014cf0f6b 12. /build/src/Interpreters/InterpreterKillQueryQuery.cpp:222: DB::InterpreterKillQueryQuery::execute() @ 0x0000000014cebde2 13. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88dc9 14. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 15. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 16. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 17. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 18. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 19. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 20. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 21. ? @ 0x00007fbc6213eac3 22. ? @ 0x00007fbc621d0850 2025.07.28 12:02:16.498397 [ 62325 ] {} TCPHandler: Code: 394. DB::Exception: Query was cancelled. (QUERY_WAS_CANCELLED), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000000a074fcb 4. /build/src/Interpreters/ProcessList.cpp:567: DB::QueryStatus::throwQueryWasCancelled() const @ 0x0000000014a4bc85 5. /build/src/Interpreters/ProcessList.cpp:520: DB::QueryStatus::throwProperExceptionIfNeeded(unsigned long const&, unsigned long const&) @ 0x0000000014a4bbd9 6. /build/src/Interpreters/ProcessList.cpp:531: DB::QueryStatus::addPipelineExecutor(DB::PipelineExecutor*) @ 0x0000000014a4bd9c 7. /build/src/Processors/Executors/PipelineExecutor.cpp:73: DB::PipelineExecutor::PipelineExecutor(std::shared_ptr, std::allocator>>>&, std::shared_ptr) @ 0x00000000169afe31 8. /build/contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x00000000169c07b5 9. /build/src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x00000000169c0978 10. /build/src/Interpreters/InterpreterKillQueryQuery.cpp:439: DB::InterpreterKillQueryQuery::getSelectResult(String const&, String const&) @ 0x0000000014cf0f04 11. /build/src/Interpreters/InterpreterKillQueryQuery.cpp:222: DB::InterpreterKillQueryQuery::execute() @ 0x0000000014cebde2 12. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88dc9 13. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 14. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 15. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 16. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 17. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 18. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 19. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 20. ? @ 0x00007fbc6213eac3 21. ? @ 0x00007fbc621d0850 2025.07.28 12:02:16.544572 [ 4446 ] {} TCPHandler: Code: 394. DB::Exception: Query was cancelled. (QUERY_WAS_CANCELLED), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000000a074fcb 4. /build/src/Interpreters/ProcessList.cpp:567: DB::QueryStatus::throwQueryWasCancelled() const @ 0x0000000014a4bc85 5. /build/src/Interpreters/ProcessList.cpp:520: DB::QueryStatus::throwProperExceptionIfNeeded(unsigned long const&, unsigned long const&) @ 0x0000000014a4bbd9 6. /build/src/Interpreters/ProcessList.cpp:557: DB::QueryStatus::checkTimeLimit() @ 0x0000000014a4c2cd 7. /build/src/Processors/Executors/PipelineExecutor.cpp:206: DB::PipelineExecutor::finalizeExecution() @ 0x00000000169b13ba 8. /build/src/Processors/Executors/PipelineExecutor.cpp:153: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x00000000169b0584 9. /build/src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:se190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169bfeab 10. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc3d92 11. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fcca080 12. ? @ 0x00007fbc6213eac3 13. ? @ 0x00007fbc621d0850 Job's origin stack trace: 0. /build/src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000000fc33b84 1. /build/src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000000fcc2ea7 2. /build/src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fcc535c 3. /build/src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000000fcc584d 4. /build/src/Common/ThreadPool.h:279: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x00000000169bf193 5. /build/src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x00000000169bf518 6. /build/src/Server/TCPHandler.cpp:1237: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x00000000168f1525 7. /build/src/Server/TCPHandler.cpp:678: DB::TCPHandler::runImpl() @ 0x00000000168e68e5 8. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 9. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 10. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 11. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 12. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 13. ? @ 0x00007fbc6213eac3 14. ? @ 0x00007fbc621d0850 2025.07.28 12:02:16.545121 [ 62053 ] {} TCPHandler: Code: 394. DB::Exception: Query was cancelled. (QUERY_WAS_CANCELLED), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000000a074fcb 4. /build/src/Interpreters/ProcessList.cpp:567: DB::QueryStatus::throwQueryWasCancelled() const @ 0x0000000014a4bc85 5. /build/src/Interpreters/ProcessList.cpp:520: DB::QueryStatus::throwProperExceptionIfNeeded(unsigned long const&, unsigned long const&) @ 0x0000000014a4bbd9 6. /build/src/Interpreters/ProcessList.cpp:557: DB::QueryStatus::checkTimeLimit() @ 0x0000000014a4c2cd 7. /build/src/Processors/Executors/PipelineExecutor.cpp:206: DB::PipelineExecutor::finalizeExecution() @ 0x00000000169b13ba 8. /build/src/Processors/Executors/PipelineExecutor.cpp:153: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x00000000169b0584 9. /build/src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:se190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169bfeab 10. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc3d92 11. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fcca080 12. ? @ 0x00007fbc6213eac3 13. ? @ 0x00007fbc621d0850 Job's origin stack trace: 0. /build/src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000000fc33b84 1. /build/src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000000fcc2ea7 2. /build/src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fcc535c 3. /build/src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000000fcc584d 4. /build/src/Common/ThreadPool.h:279: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x00000000169bf193 5. /build/src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x00000000169bf518 6. /build/src/Server/TCPHandler.cpp:1237: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x00000000168f1525 7. /build/src/Server/TCPHandler.cpp:678: DB::TCPHandler::runImpl() @ 0x00000000168e68e5 8. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 9. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 10. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 11. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 12. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 13. ? @ 0x00007fbc6213eac3 14. ? @ 0x00007fbc621d0850 2025.07.28 12:02:16.680016 [ 17255 ] {50959597-985c-4aac-ab92-b26666b66454} executeQuery: Code: 394. DB::Exception: Query was cancelled. (QUERY_WAS_CANCELLED) (version 25.3.6.10636.altinitytest (altinity build)) (from [::1]:44404) (comment: 02461_cancel_finish_race.sh) (query 1, line 1) (in query: KILL QUERY WHERE current_database = 'test_dtwle8fg' SYNC FORMAT Null), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000000a074fcb 4. /build/src/Interpreters/ProcessList.cpp:567: DB::QueryStatus::throwQueryWasCancelled() const @ 0x0000000014a4bc85 5. /build/src/Interpreters/ProcessList.cpp:520: DB::QueryStatus::throwProperExceptionIfNeeded(unsigned long const&, unsigned long const&) @ 0x0000000014a4bbd9 6. /build/src/Interpreters/ProcessList.cpp:557: DB::QueryStatus::checkTimeLimit() @ 0x0000000014a4c2cd 7. /build/src/Processors/Executors/PipelineExecutor.cpp:206: DB::PipelineExecutor::finalizeExecution() @ 0x00000000169b13ba 8. /build/src/Processors/Executors/PipelineExecutor.cpp:153: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x00000000169b0584 9. /build/src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:se190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169bfeab 10. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc3d92 11. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fcca080 12. ? @ 0x00007fbc6213eac3 13. ? @ 0x00007fbc621d0850 2025.07.28 12:02:16.693402 [ 17255 ] {} TCPHandler: Code: 394. DB::Exception: Query was cancelled. (QUERY_WAS_CANCELLED), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000000a074fcb 4. /build/src/Interpreters/ProcessList.cpp:567: DB::QueryStatus::throwQueryWasCancelled() const @ 0x0000000014a4bc85 5. /build/src/Interpreters/ProcessList.cpp:520: DB::QueryStatus::throwProperExceptionIfNeeded(unsigned long const&, unsigned long const&) @ 0x0000000014a4bbd9 6. /build/src/Interpreters/ProcessList.cpp:557: DB::QueryStatus::checkTimeLimit() @ 0x0000000014a4c2cd 7. /build/src/Processors/Executors/PipelineExecutor.cpp:206: DB::PipelineExecutor::finalizeExecution() @ 0x00000000169b13ba 8. /build/src/Processors/Executors/PipelineExecutor.cpp:153: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x00000000169b0584 9. /build/src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:se190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169bfeab 10. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc3d92 11. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fcca080 12. ? @ 0x00007fbc6213eac3 13. ? @ 0x00007fbc621d0850 Job's origin stack trace: 0. /build/src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000000fc33b84 1. /build/src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000000fcc2ea7 2. /build/src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fcc535c 3. /build/src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000000fcc584d 4. /build/src/Common/ThreadPool.h:279: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x00000000169bf193 5. /build/src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x00000000169bf518 6. /build/src/Server/TCPHandler.cpp:1237: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x00000000168f1525 7. /build/src/Server/TCPHandler.cpp:678: DB::TCPHandler::runImpl() @ 0x00000000168e68e5 8. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 9. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 10. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 11. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 12. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 13. ? @ 0x00007fbc6213eac3 14. ? @ 0x00007fbc621d0850 2025.07.28 12:02:16.838616 [ 3963 ] {} test_13.rmt2 (7f9b740d-015c-470e-8cc6-8ba33be0dc63): auto DB::StorageReplicatedMergeTree::processQueueEntry(ReplicatedMergeTreeQueue::SelectedEntryPtr)::(anonymous class)::operator()(LogEntryPtr &) const: Code: 86. DB::HTTPException: Received error from remote server http://146b4357c08d:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Ftest%2F01165%2Ftest_13%2Frmt%2Freplicas%2F1&part=20250728_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.6.10636.altinitytest (altinity build)) '. (RECEIVED_ERROR_FROM_REMOTE_IO_SERVER), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.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 const&, int&&, String const&, unsigned long&&, String const&) @ 0x000000000feda8d9 4. /build/src/IO/HTTPCommon.cpp:104: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x000000000feda6e2 5. /build/src/IO/HTTPCommon.cpp:93: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x000000000feda537 6. /build/src/IO/ReadWriteBufferFromHTTP.cpp:277: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x000000001184a4c4 7. /build/src/IO/ReadWriteBufferFromHTTP.cpp:285: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x000000001184a615 8. /build/src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x000000001184ae59 9. /build/src/IO/ReadWriteBufferFromHTTP.cpp:472: void std::__function::__policy_invoker::__call_impl[abi:se190107]>(std::__function::__policy_storage const*) @ 0x000000001184cedd 10. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001184858b 11. /build/src/IO/ReadWriteBufferFromHTTP.cpp:465: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x000000001184bf0b 12. /build/src/IO/ReadBuffer.h:60: DB::ReadBuffer::next() @ 0x000000000a148c7b 13. /build/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) @ 0x0000000011849fb2 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]>&)>&, 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&) @ 0x0000000011841980 15. /build/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) @ 0x000000001621208e 16. /build/src/Storages/StorageReplicatedMergeTree.cpp:5228: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl[abi:se190107] const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000015f9a5fe 17. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000015ed8bfd 18. /build/src/Storages/StorageReplicatedMergeTree.cpp:2514: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x0000000015ec9aab 19. /build/src/Storages/StorageReplicatedMergeTree.cpp:2349: DB::StorageReplicatedMergeTree::executeLogEntry(DB::ReplicatedMergeTreeLogEntry&) @ 0x0000000015eba91b 20. /build/src/Storages/StorageReplicatedMergeTree.cpp:3876: bool std::__function::__policy_invoker&)>::__call_impl[abi:se190107])::$_1, bool (std::shared_ptr&)>>(std::__function::__policy_storage const*, std::shared_ptr&) @ 0x0000000015f9837e 21. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000165d6fc3 22. /build/src/Storages/StorageReplicatedMergeTree.cpp:3872: DB::StorageReplicatedMergeTree::processQueueEntry(std::shared_ptr) @ 0x0000000015efc18a 23. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001624c1b2 24. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000162f9c70 25. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x00000000162fa55a 26. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc6653 27. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000000fccc4c3 28. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc3d92 29. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fcca080 30. ? @ 0x00007fbc6213eac3 31. ? @ 0x00007fbc621d0850 (version 25.3.6.10636.altinitytest (altinity build)) 2025.07.28 12:02:16.994019 [ 11826 ] {} TCPHandler: Code: 394. DB::Exception: Query 'fb7b1a3e-7394-4a20-98b7-c20ff4dddfda' is killed in pending state. (QUERY_WAS_CANCELLED), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x000000000a06b56b 4. /build/src/Interpreters/executeQuery.cpp:1522: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c8a4ef 5. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 6. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 7. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 8. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 9. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 10. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 11. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 12. ? @ 0x00007fbc6213eac3 13. ? @ 0x00007fbc621d0850 2025.07.28 12:02:16.999862 [ 62325 ] {2b9d121e-3be7-48b6-869b-0654e0d946d8} executeQuery: Code: 394. DB::Exception: Query was cancelled. (QUERY_WAS_CANCELLED) (version 25.3.6.10636.altinitytest (altinity build)) (from [::1]:44626) (comment: 02461_cancel_finish_race.sh) (query 1, line 1) (in query: KILL QUERY WHERE current_database = 'test_dtwle8fg' SYNC FORMAT Null), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000000a074fcb 4. /build/src/Interpreters/ProcessList.cpp:567: DB::QueryStatus::throwQueryWasCancelled() const @ 0x0000000014a4bc85 5. /build/src/Interpreters/ProcessList.cpp:520: DB::QueryStatus::throwProperExceptionIfNeeded(unsigned long const&, unsigned long const&) @ 0x0000000014a4bbd9 6. /build/src/Interpreters/ProcessList.cpp:531: DB::QueryStatus::addPipelineExecutor(DB::PipelineExecutor*) @ 0x0000000014a4bd9c 7. /build/src/Processors/Executors/PipelineExecutor.cpp:73: DB::PipelineExecutor::PipelineExecutor(std::shared_ptr, std::allocator>>>&, std::shared_ptr) @ 0x00000000169afe31 8. /build/contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x00000000169bef66 9. /build/src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x00000000169bf518 10. /build/src/Server/TCPHandler.cpp:1237: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x00000000168f1525 11. /build/src/Server/TCPHandler.cpp:678: DB::TCPHandler::runImpl() @ 0x00000000168e68e5 12. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 13. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 14. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 16. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 17. ? @ 0x00007fbc6213eac3 18. ? @ 0x00007fbc621d0850 2025.07.28 12:02:17.011965 [ 63425 ] {07a94020-a409-4e57-be74-e1a7a4821b13} executeQuery: Code: 394. DB::Exception: Query was cancelled. (QUERY_WAS_CANCELLED) (version 25.3.6.10636.altinitytest (altinity build)) (from [::1]:44598) (comment: 02461_cancel_finish_race.sh) (query 1, line 1) (in query: KILL QUERY WHERE current_database = 'test_dtwle8fg' SYNC FORMAT Null), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000000a074fcb 4. /build/src/Interpreters/ProcessList.cpp:567: DB::QueryStatus::throwQueryWasCancelled() const @ 0x0000000014a4bc85 5. /build/src/Interpreters/ProcessList.cpp:520: DB::QueryStatus::throwProperExceptionIfNeeded(unsigned long const&, unsigned long const&) @ 0x0000000014a4bbd9 6. /build/src/Interpreters/ProcessList.cpp:557: DB::QueryStatus::checkTimeLimit() @ 0x0000000014a4c2cd 7. /build/src/Processors/Executors/PipelineExecutor.cpp:206: DB::PipelineExecutor::finalizeExecution() @ 0x00000000169b13ba 8. /build/src/Processors/Executors/PipelineExecutor.cpp:153: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x00000000169b0584 9. /build/src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:se190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169bfeab 10. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc3d92 11. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fcca080 12. ? @ 0x00007fbc6213eac3 13. ? @ 0x00007fbc621d0850 2025.07.28 12:02:17.055235 [ 17371 ] {d8f13054-b7c5-40f5-8d1c-7bc6142504ee} executeQuery: Code: 394. DB::Exception: Query was cancelled. (QUERY_WAS_CANCELLED) (version 25.3.6.10636.altinitytest (altinity build)) (from [::1]:44494) (comment: 02461_cancel_finish_race.sh) (query 1, line 1) (in query: KILL QUERY WHERE current_database = 'test_dtwle8fg' SYNC FORMAT Null), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000000a074fcb 4. /build/src/Interpreters/ProcessList.cpp:567: DB::QueryStatus::throwQueryWasCancelled() const @ 0x0000000014a4bc85 5. /build/src/Interpreters/ProcessList.cpp:520: DB::QueryStatus::throwProperExceptionIfNeeded(unsigned long const&, unsigned long const&) @ 0x0000000014a4bbd9 6. /build/src/Interpreters/ProcessList.cpp:557: DB::QueryStatus::checkTimeLimit() @ 0x0000000014a4c2cd 7. /build/src/Processors/Executors/PipelineExecutor.cpp:206: DB::PipelineExecutor::finalizeExecution() @ 0x00000000169b13ba 8. /build/src/Processors/Executors/PipelineExecutor.cpp:153: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x00000000169b0584 9. /build/src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:se190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169bfeab 10. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc3d92 11. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fcca080 12. ? @ 0x00007fbc6213eac3 13. ? @ 0x00007fbc621d0850 2025.07.28 12:02:17.055498 [ 62075 ] {} TCPHandler: Code: 394. DB::Exception: Query was cancelled. (QUERY_WAS_CANCELLED), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000000a074fcb 4. /build/src/Interpreters/ProcessList.cpp:567: DB::QueryStatus::throwQueryWasCancelled() const @ 0x0000000014a4bc85 5. /build/src/Interpreters/ProcessList.cpp:520: DB::QueryStatus::throwProperExceptionIfNeeded(unsigned long const&, unsigned long const&) @ 0x0000000014a4bbd9 6. /build/src/Interpreters/ProcessList.cpp:557: DB::QueryStatus::checkTimeLimit() @ 0x0000000014a4c2cd 7. /build/src/Processors/Executors/PipelineExecutor.cpp:206: DB::PipelineExecutor::finalizeExecution() @ 0x00000000169b13ba 8. /build/src/Processors/Executors/PipelineExecutor.cpp:181: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x00000000169b1726 9. /build/src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x00000000169c081c 10. /build/src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x00000000169c0978 11. /build/src/Interpreters/InterpreterKillQueryQuery.cpp:442: DB::InterpreterKillQueryQuery::getSelectResult(String const&, String const&) @ 0x0000000014cf0f6b 12. /build/src/Interpreters/InterpreterKillQueryQuery.cpp:222: DB::InterpreterKillQueryQuery::execute() @ 0x0000000014cebde2 13. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88dc9 14. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 15. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 16. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 17. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 18. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 19. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 20. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 21. ? @ 0x00007fbc6213eac3 22. ? @ 0x00007fbc621d0850 2025.07.28 12:02:17.057543 [ 62325 ] {} TCPHandler: Code: 394. DB::Exception: Query was cancelled. (QUERY_WAS_CANCELLED), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000000a074fcb 4. /build/src/Interpreters/ProcessList.cpp:567: DB::QueryStatus::throwQueryWasCancelled() const @ 0x0000000014a4bc85 5. /build/src/Interpreters/ProcessList.cpp:520: DB::QueryStatus::throwProperExceptionIfNeeded(unsigned long const&, unsigned long const&) @ 0x0000000014a4bbd9 6. /build/src/Interpreters/ProcessList.cpp:531: DB::QueryStatus::addPipelineExecutor(DB::PipelineExecutor*) @ 0x0000000014a4bd9c 7. /build/src/Processors/Executors/PipelineExecutor.cpp:73: DB::PipelineExecutor::PipelineExecutor(std::shared_ptr, std::allocator>>>&, std::shared_ptr) @ 0x00000000169afe31 8. /build/contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x00000000169bef66 9. /build/src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x00000000169bf518 10. /build/src/Server/TCPHandler.cpp:1237: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x00000000168f1525 11. /build/src/Server/TCPHandler.cpp:678: DB::TCPHandler::runImpl() @ 0x00000000168e68e5 12. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 13. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 14. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 16. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 17. ? @ 0x00007fbc6213eac3 18. ? @ 0x00007fbc621d0850 2025.07.28 12:02:17.072515 [ 17371 ] {} TCPHandler: Code: 394. DB::Exception: Query was cancelled. (QUERY_WAS_CANCELLED), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000000a074fcb 4. /build/src/Interpreters/ProcessList.cpp:567: DB::QueryStatus::throwQueryWasCancelled() const @ 0x0000000014a4bc85 5. /build/src/Interpreters/ProcessList.cpp:520: DB::QueryStatus::throwProperExceptionIfNeeded(unsigned long const&, unsigned long const&) @ 0x0000000014a4bbd9 6. /build/src/Interpreters/ProcessList.cpp:557: DB::QueryStatus::checkTimeLimit() @ 0x0000000014a4c2cd 7. /build/src/Processors/Executors/PipelineExecutor.cpp:206: DB::PipelineExecutor::finalizeExecution() @ 0x00000000169b13ba 8. /build/src/Processors/Executors/PipelineExecutor.cpp:153: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x00000000169b0584 9. /build/src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:se190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169bfeab 10. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc3d92 11. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fcca080 12. ? @ 0x00007fbc6213eac3 13. ? @ 0x00007fbc621d0850 Job's origin stack trace: 0. /build/src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000000fc33b84 1. /build/src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000000fcc2ea7 2. /build/src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fcc535c 3. /build/src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000000fcc584d 4. /build/src/Common/ThreadPool.h:279: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x00000000169bf193 5. /build/src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x00000000169bf518 6. /build/src/Server/TCPHandler.cpp:1237: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x00000000168f1525 7. /build/src/Server/TCPHandler.cpp:678: DB::TCPHandler::runImpl() @ 0x00000000168e68e5 8. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 9. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 10. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 11. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 12. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 13. ? @ 0x00007fbc6213eac3 14. ? @ 0x00007fbc621d0850 2025.07.28 12:02:17.073104 [ 62093 ] {01743b46-a907-45b4-a7c6-c644914008bf} executeQuery: Code: 394. DB::Exception: Query was cancelled. (QUERY_WAS_CANCELLED) (version 25.3.6.10636.altinitytest (altinity build)) (from [::1]:44574) (comment: 02461_cancel_finish_race.sh) (query 1, line 1) (in query: KILL QUERY WHERE current_database = 'test_dtwle8fg' SYNC FORMAT Null), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000000a074fcb 4. /build/src/Interpreters/ProcessList.cpp:567: DB::QueryStatus::throwQueryWasCancelled() const @ 0x0000000014a4bc85 5. /build/src/Interpreters/ProcessList.cpp:520: DB::QueryStatus::throwProperExceptionIfNeeded(unsigned long const&, unsigned long const&) @ 0x0000000014a4bbd9 6. /build/src/Interpreters/ProcessList.cpp:557: DB::QueryStatus::checkTimeLimit() @ 0x0000000014a4c2cd 7. /build/src/Processors/Executors/PipelineExecutor.cpp:206: DB::PipelineExecutor::finalizeExecution() @ 0x00000000169b13ba 8. /build/src/Processors/Executors/PipelineExecutor.cpp:153: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x00000000169b0584 9. /build/src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:se190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169bfeab 10. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc3d92 11. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fcca080 12. ? @ 0x00007fbc6213eac3 13. ? @ 0x00007fbc621d0850 2025.07.28 12:02:17.097452 [ 63425 ] {} TCPHandler: Code: 394. DB::Exception: Query was cancelled. (QUERY_WAS_CANCELLED), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000000a074fcb 4. /build/src/Interpreters/ProcessList.cpp:567: DB::QueryStatus::throwQueryWasCancelled() const @ 0x0000000014a4bc85 5. /build/src/Interpreters/ProcessList.cpp:520: DB::QueryStatus::throwProperExceptionIfNeeded(unsigned long const&, unsigned long const&) @ 0x0000000014a4bbd9 6. /build/src/Interpreters/ProcessList.cpp:557: DB::QueryStatus::checkTimeLimit() @ 0x0000000014a4c2cd 7. /build/src/Processors/Executors/PipelineExecutor.cpp:206: DB::PipelineExecutor::finalizeExecution() @ 0x00000000169b13ba 8. /build/src/Processors/Executors/PipelineExecutor.cpp:153: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x00000000169b0584 9. /build/src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:se190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169bfeab 10. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc3d92 11. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fcca080 12. ? @ 0x00007fbc6213eac3 13. ? @ 0x00007fbc621d0850 Job's origin stack trace: 0. /build/src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000000fc33b84 1. /build/src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000000fcc2ea7 2. /build/src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fcc535c 3. /build/src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000000fcc584d 4. /build/src/Common/ThreadPool.h:279: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x00000000169bf193 5. /build/src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x00000000169bf518 6. /build/src/Server/TCPHandler.cpp:1237: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x00000000168f1525 7. /build/src/Server/TCPHandler.cpp:678: DB::TCPHandler::runImpl() @ 0x00000000168e68e5 8. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 9. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 10. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 11. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 12. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 13. ? @ 0x00007fbc6213eac3 14. ? @ 0x00007fbc621d0850 2025.07.28 12:02:17.102078 [ 62093 ] {} TCPHandler: Code: 394. DB::Exception: Query was cancelled. (QUERY_WAS_CANCELLED), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000000a074fcb 4. /build/src/Interpreters/ProcessList.cpp:567: DB::QueryStatus::throwQueryWasCancelled() const @ 0x0000000014a4bc85 5. /build/src/Interpreters/ProcessList.cpp:520: DB::QueryStatus::throwProperExceptionIfNeeded(unsigned long const&, unsigned long const&) @ 0x0000000014a4bbd9 6. /build/src/Interpreters/ProcessList.cpp:557: DB::QueryStatus::checkTimeLimit() @ 0x0000000014a4c2cd 7. /build/src/Processors/Executors/PipelineExecutor.cpp:206: DB::PipelineExecutor::finalizeExecution() @ 0x00000000169b13ba 8. /build/src/Processors/Executors/PipelineExecutor.cpp:153: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x00000000169b0584 9. /build/src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:se190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169bfeab 10. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc3d92 11. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fcca080 12. ? @ 0x00007fbc6213eac3 13. ? @ 0x00007fbc621d0850 Job's origin stack trace: 0. /build/src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000000fc33b84 1. /build/src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000000fcc2ea7 2. /build/src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fcc535c 3. /build/src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000000fcc584d 4. /build/src/Common/ThreadPool.h:279: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x00000000169bf193 5. /build/src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x00000000169bf518 6. /build/src/Server/TCPHandler.cpp:1237: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x00000000168f1525 7. /build/src/Server/TCPHandler.cpp:678: DB::TCPHandler::runImpl() @ 0x00000000168e68e5 8. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 9. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 10. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 11. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 12. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 13. ? @ 0x00007fbc6213eac3 14. ? @ 0x00007fbc621d0850 2025.07.28 12:02:17.119177 [ 62065 ] {} TCPHandler: Code: 394. DB::Exception: Query was cancelled. (QUERY_WAS_CANCELLED), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000000a074fcb 4. /build/src/Interpreters/ProcessList.cpp:567: DB::QueryStatus::throwQueryWasCancelled() const @ 0x0000000014a4bc85 5. /build/src/Interpreters/ProcessList.cpp:520: DB::QueryStatus::throwProperExceptionIfNeeded(unsigned long const&, unsigned long const&) @ 0x0000000014a4bbd9 6. /build/src/Interpreters/ProcessList.cpp:531: DB::QueryStatus::addPipelineExecutor(DB::PipelineExecutor*) @ 0x0000000014a4bd9c 7. /build/src/Processors/Executors/PipelineExecutor.cpp:73: DB::PipelineExecutor::PipelineExecutor(std::shared_ptr, std::allocator>>>&, std::shared_ptr) @ 0x00000000169afe31 8. /build/contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x00000000169c07b5 9. /build/src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x00000000169c0978 10. /build/src/Interpreters/InterpreterKillQueryQuery.cpp:439: DB::InterpreterKillQueryQuery::getSelectResult(String const&, String const&) @ 0x0000000014cf0f04 11. /build/src/Interpreters/InterpreterKillQueryQuery.cpp:222: DB::InterpreterKillQueryQuery::execute() @ 0x0000000014cebde2 12. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88dc9 13. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 14. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 15. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 16. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 17. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 18. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 19. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 20. ? @ 0x00007fbc6213eac3 21. ? @ 0x00007fbc621d0850 2025.07.28 12:02:17.129158 [ 3972 ] {} test_13.rmt2 (7f9b740d-015c-470e-8cc6-8ba33be0dc63): auto DB::StorageReplicatedMergeTree::processQueueEntry(ReplicatedMergeTreeQueue::SelectedEntryPtr)::(anonymous class)::operator()(LogEntryPtr &) const: Code: 86. DB::HTTPException: Received error from remote server http://146b4357c08d:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Ftest%2F01165%2Ftest_13%2Frmt%2Freplicas%2F1&part=20250728_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.6.10636.altinitytest (altinity build)) '. (RECEIVED_ERROR_FROM_REMOTE_IO_SERVER), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.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 const&, int&&, String const&, unsigned long&&, String const&) @ 0x000000000feda8d9 4. /build/src/IO/HTTPCommon.cpp:104: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x000000000feda6e2 5. /build/src/IO/HTTPCommon.cpp:93: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x000000000feda537 6. /build/src/IO/ReadWriteBufferFromHTTP.cpp:277: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x000000001184a4c4 7. /build/src/IO/ReadWriteBufferFromHTTP.cpp:285: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x000000001184a615 8. /build/src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x000000001184ae59 9. /build/src/IO/ReadWriteBufferFromHTTP.cpp:472: void std::__function::__policy_invoker::__call_impl[abi:se190107]>(std::__function::__policy_storage const*) @ 0x000000001184cedd 10. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001184858b 11. /build/src/IO/ReadWriteBufferFromHTTP.cpp:465: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x000000001184bf0b 12. /build/src/IO/ReadBuffer.h:60: DB::ReadBuffer::next() @ 0x000000000a148c7b 13. /build/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) @ 0x0000000011849fb2 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]>&)>&, 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&) @ 0x0000000011841980 15. /build/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) @ 0x000000001621208e 16. /build/src/Storages/StorageReplicatedMergeTree.cpp:5228: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl[abi:se190107] const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000015f9a5fe 17. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000015ed8bfd 18. /build/src/Storages/StorageReplicatedMergeTree.cpp:2514: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x0000000015ec9aab 19. /build/src/Storages/StorageReplicatedMergeTree.cpp:2349: DB::StorageReplicatedMergeTree::executeLogEntry(DB::ReplicatedMergeTreeLogEntry&) @ 0x0000000015eba91b 20. /build/src/Storages/StorageReplicatedMergeTree.cpp:3876: bool std::__function::__policy_invoker&)>::__call_impl[abi:se190107])::$_1, bool (std::shared_ptr&)>>(std::__function::__policy_storage const*, std::shared_ptr&) @ 0x0000000015f9837e 21. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000165d6fc3 22. /build/src/Storages/StorageReplicatedMergeTree.cpp:3872: DB::StorageReplicatedMergeTree::processQueueEntry(std::shared_ptr) @ 0x0000000015efc18a 23. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001624c1b2 24. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000162f9c70 25. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x00000000162fa55a 26. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc6653 27. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000000fccc4c3 28. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc3d92 29. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fcca080 30. ? @ 0x00007fbc6213eac3 31. ? @ 0x00007fbc621d0850 (version 25.3.6.10636.altinitytest (altinity build)) 2025.07.28 12:02:17.254884 [ 62055 ] {30059367-bf6d-4ef1-b814-5a01805d6795} executeQuery: Code: 394. DB::Exception: Query was cancelled. (QUERY_WAS_CANCELLED) (version 25.3.6.10636.altinitytest (altinity build)) (from [::1]:44710) (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. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000000a074fcb 4. /build/src/Interpreters/ProcessList.cpp:567: DB::QueryStatus::throwQueryWasCancelled() const @ 0x0000000014a4bc85 5. /build/src/Interpreters/ProcessList.cpp:520: DB::QueryStatus::throwProperExceptionIfNeeded(unsigned long const&, unsigned long const&) @ 0x0000000014a4bbd9 6. /build/src/Interpreters/ProcessList.cpp:557: DB::QueryStatus::checkTimeLimit() @ 0x0000000014a4c2cd 7. /build/src/Processors/Executors/PipelineExecutor.cpp:206: DB::PipelineExecutor::finalizeExecution() @ 0x00000000169b13ba 8. /build/src/Processors/Executors/PipelineExecutor.cpp:153: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x00000000169b0584 9. /build/src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:se190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169bfeab 10. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc3d92 11. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fcca080 12. ? @ 0x00007fbc6213eac3 13. ? @ 0x00007fbc621d0850 2025.07.28 12:02:17.287851 [ 62056 ] {01c0c02d-4eda-45b9-96a9-f104b3a9fe99} executeQuery: Code: 394. DB::Exception: Query was cancelled. (QUERY_WAS_CANCELLED) (version 25.3.6.10636.altinitytest (altinity build)) (from [::1]:44690) (comment: 02461_cancel_finish_race.sh) (query 1, line 1) (in query: KILL QUERY WHERE current_database = 'test_dtwle8fg' SYNC FORMAT Null), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000000a074fcb 4. /build/src/Interpreters/ProcessList.cpp:567: DB::QueryStatus::throwQueryWasCancelled() const @ 0x0000000014a4bc85 5. /build/src/Interpreters/ProcessList.cpp:520: DB::QueryStatus::throwProperExceptionIfNeeded(unsigned long const&, unsigned long const&) @ 0x0000000014a4bbd9 6. /build/src/Interpreters/ProcessList.cpp:557: DB::QueryStatus::checkTimeLimit() @ 0x0000000014a4c2cd 7. /build/src/Processors/Executors/PipelineExecutor.cpp:206: DB::PipelineExecutor::finalizeExecution() @ 0x00000000169b13ba 8. /build/src/Processors/Executors/PipelineExecutor.cpp:153: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x00000000169b0584 9. /build/src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:se190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169bfeab 10. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc3d92 11. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fcca080 12. ? @ 0x00007fbc6213eac3 13. ? @ 0x00007fbc621d0850 2025.07.28 12:02:17.288708 [ 62055 ] {} TCPHandler: Code: 394. DB::Exception: Query was cancelled. (QUERY_WAS_CANCELLED), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000000a074fcb 4. /build/src/Interpreters/ProcessList.cpp:567: DB::QueryStatus::throwQueryWasCancelled() const @ 0x0000000014a4bc85 5. /build/src/Interpreters/ProcessList.cpp:520: DB::QueryStatus::throwProperExceptionIfNeeded(unsigned long const&, unsigned long const&) @ 0x0000000014a4bbd9 6. /build/src/Interpreters/ProcessList.cpp:557: DB::QueryStatus::checkTimeLimit() @ 0x0000000014a4c2cd 7. /build/src/Processors/Executors/PipelineExecutor.cpp:206: DB::PipelineExecutor::finalizeExecution() @ 0x00000000169b13ba 8. /build/src/Processors/Executors/PipelineExecutor.cpp:153: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x00000000169b0584 9. /build/src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:se190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169bfeab 10. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc3d92 11. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fcca080 12. ? @ 0x00007fbc6213eac3 13. ? @ 0x00007fbc621d0850 Job's origin stack trace: 0. /build/src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000000fc33b84 1. /build/src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000000fcc2ea7 2. /build/src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fcc535c 3. /build/src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000000fcc584d 4. /build/src/Common/ThreadPool.h:279: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x00000000169bf193 5. /build/src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x00000000169bf518 6. /build/src/Server/TCPHandler.cpp:1237: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x00000000168f1525 7. /build/src/Server/TCPHandler.cpp:678: DB::TCPHandler::runImpl() @ 0x00000000168e68e5 8. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 9. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 10. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 11. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 12. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 13. ? @ 0x00007fbc6213eac3 14. ? @ 0x00007fbc621d0850 2025.07.28 12:02:17.294051 [ 4446 ] {} TCPHandler: Code: 394. DB::Exception: Query was cancelled. (QUERY_WAS_CANCELLED), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000000a074fcb 4. /build/src/Interpreters/ProcessList.cpp:567: DB::QueryStatus::throwQueryWasCancelled() const @ 0x0000000014a4bc85 5. /build/src/Interpreters/ProcessList.cpp:520: DB::QueryStatus::throwProperExceptionIfNeeded(unsigned long const&, unsigned long const&) @ 0x0000000014a4bbd9 6. /build/src/Interpreters/ProcessList.cpp:557: DB::QueryStatus::checkTimeLimit() @ 0x0000000014a4c2cd 7. /build/src/Processors/Executors/PipelineExecutor.cpp:206: DB::PipelineExecutor::finalizeExecution() @ 0x00000000169b13ba 8. /build/src/Processors/Executors/PipelineExecutor.cpp:181: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x00000000169b1726 9. /build/src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x00000000169c081c 10. /build/src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x00000000169c0978 11. /build/src/Interpreters/InterpreterKillQueryQuery.cpp:439: DB::InterpreterKillQueryQuery::getSelectResult(String const&, String const&) @ 0x0000000014cf0f04 12. /build/src/Interpreters/InterpreterKillQueryQuery.cpp:222: DB::InterpreterKillQueryQuery::execute() @ 0x0000000014cebde2 13. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88dc9 14. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 15. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 16. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 17. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 18. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 19. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 20. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 21. ? @ 0x00007fbc6213eac3 22. ? @ 0x00007fbc621d0850 2025.07.28 12:02:17.310607 [ 62056 ] {} TCPHandler: Code: 394. DB::Exception: Query was cancelled. (QUERY_WAS_CANCELLED), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000000a074fcb 4. /build/src/Interpreters/ProcessList.cpp:567: DB::QueryStatus::throwQueryWasCancelled() const @ 0x0000000014a4bc85 5. /build/src/Interpreters/ProcessList.cpp:520: DB::QueryStatus::throwProperExceptionIfNeeded(unsigned long const&, unsigned long const&) @ 0x0000000014a4bbd9 6. /build/src/Interpreters/ProcessList.cpp:557: DB::QueryStatus::checkTimeLimit() @ 0x0000000014a4c2cd 7. /build/src/Processors/Executors/PipelineExecutor.cpp:206: DB::PipelineExecutor::finalizeExecution() @ 0x00000000169b13ba 8. /build/src/Processors/Executors/PipelineExecutor.cpp:153: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x00000000169b0584 9. /build/src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:se190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169bfeab 10. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc3d92 11. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fcca080 12. ? @ 0x00007fbc6213eac3 13. ? @ 0x00007fbc621d0850 Job's origin stack trace: 0. /build/src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000000fc33b84 1. /build/src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000000fcc2ea7 2. /build/src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fcc535c 3. /build/src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000000fcc584d 4. /build/src/Common/ThreadPool.h:279: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x00000000169bf193 5. /build/src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x00000000169bf518 6. /build/src/Server/TCPHandler.cpp:1237: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x00000000168f1525 7. /build/src/Server/TCPHandler.cpp:678: DB::TCPHandler::runImpl() @ 0x00000000168e68e5 8. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 9. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 10. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 11. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 12. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 13. ? @ 0x00007fbc6213eac3 14. ? @ 0x00007fbc621d0850 2025.07.28 12:02:17.371005 [ 62058 ] {e3c727b2-3dbe-4249-8a82-dc499530a0cb} executeQuery: Code: 394. DB::Exception: Query was cancelled. (QUERY_WAS_CANCELLED) (version 25.3.6.10636.altinitytest (altinity build)) (from [::1]:44724) (comment: 02461_cancel_finish_race.sh) (query 1, line 1) (in query: KILL QUERY WHERE current_database = 'test_dtwle8fg' SYNC FORMAT Null), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000000a074fcb 4. /build/src/Interpreters/ProcessList.cpp:567: DB::QueryStatus::throwQueryWasCancelled() const @ 0x0000000014a4bc85 5. /build/src/Interpreters/ProcessList.cpp:520: DB::QueryStatus::throwProperExceptionIfNeeded(unsigned long const&, unsigned long const&) @ 0x0000000014a4bbd9 6. /build/src/Interpreters/ProcessList.cpp:557: DB::QueryStatus::checkTimeLimit() @ 0x0000000014a4c2cd 7. /build/src/Processors/Executors/PipelineExecutor.cpp:206: DB::PipelineExecutor::finalizeExecution() @ 0x00000000169b13ba 8. /build/src/Processors/Executors/PipelineExecutor.cpp:153: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x00000000169b0584 9. /build/src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:se190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169bfeab 10. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc3d92 11. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fcca080 12. ? @ 0x00007fbc6213eac3 13. ? @ 0x00007fbc621d0850 2025.07.28 12:02:17.389102 [ 62058 ] {} TCPHandler: Code: 394. DB::Exception: Query was cancelled. (QUERY_WAS_CANCELLED), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000000a074fcb 4. /build/src/Interpreters/ProcessList.cpp:567: DB::QueryStatus::throwQueryWasCancelled() const @ 0x0000000014a4bc85 5. /build/src/Interpreters/ProcessList.cpp:520: DB::QueryStatus::throwProperExceptionIfNeeded(unsigned long const&, unsigned long const&) @ 0x0000000014a4bbd9 6. /build/src/Interpreters/ProcessList.cpp:557: DB::QueryStatus::checkTimeLimit() @ 0x0000000014a4c2cd 7. /build/src/Processors/Executors/PipelineExecutor.cpp:206: DB::PipelineExecutor::finalizeExecution() @ 0x00000000169b13ba 8. /build/src/Processors/Executors/PipelineExecutor.cpp:153: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x00000000169b0584 9. /build/src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:se190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169bfeab 10. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc3d92 11. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fcca080 12. ? @ 0x00007fbc6213eac3 13. ? @ 0x00007fbc621d0850 Job's origin stack trace: 0. /build/src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000000fc33b84 1. /build/src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000000fcc2ea7 2. /build/src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fcc535c 3. /build/src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000000fcc584d 4. /build/src/Common/ThreadPool.h:279: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x00000000169bf193 5. /build/src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x00000000169bf518 6. /build/src/Server/TCPHandler.cpp:1237: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x00000000168f1525 7. /build/src/Server/TCPHandler.cpp:678: DB::TCPHandler::runImpl() @ 0x00000000168e68e5 8. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 9. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 10. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 11. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 12. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 13. ? @ 0x00007fbc6213eac3 14. ? @ 0x00007fbc621d0850 2025.07.28 12:02:17.390325 [ 3976 ] {} test_13.rmt2 (7f9b740d-015c-470e-8cc6-8ba33be0dc63): auto DB::StorageReplicatedMergeTree::processQueueEntry(ReplicatedMergeTreeQueue::SelectedEntryPtr)::(anonymous class)::operator()(LogEntryPtr &) const: Code: 86. DB::HTTPException: Received error from remote server http://146b4357c08d:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Ftest%2F01165%2Ftest_13%2Frmt%2Freplicas%2F1&part=20250728_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.6.10636.altinitytest (altinity build)) '. (RECEIVED_ERROR_FROM_REMOTE_IO_SERVER), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.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 const&, int&&, String const&, unsigned long&&, String const&) @ 0x000000000feda8d9 4. /build/src/IO/HTTPCommon.cpp:104: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x000000000feda6e2 5. /build/src/IO/HTTPCommon.cpp:93: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x000000000feda537 6. /build/src/IO/ReadWriteBufferFromHTTP.cpp:277: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x000000001184a4c4 7. /build/src/IO/ReadWriteBufferFromHTTP.cpp:285: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x000000001184a615 8. /build/src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x000000001184ae59 9. /build/src/IO/ReadWriteBufferFromHTTP.cpp:472: void std::__function::__policy_invoker::__call_impl[abi:se190107]>(std::__function::__policy_storage const*) @ 0x000000001184cedd 10. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001184858b 11. /build/src/IO/ReadWriteBufferFromHTTP.cpp:465: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x000000001184bf0b 12. /build/src/IO/ReadBuffer.h:60: DB::ReadBuffer::next() @ 0x000000000a148c7b 13. /build/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) @ 0x0000000011849fb2 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]>&)>&, 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&) @ 0x0000000011841980 15. /build/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) @ 0x000000001621208e 16. /build/src/Storages/StorageReplicatedMergeTree.cpp:5228: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl[abi:se190107] const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000015f9a5fe 17. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000015ed8bfd 18. /build/src/Storages/StorageReplicatedMergeTree.cpp:2514: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x0000000015ec9aab 19. /build/src/Storages/StorageReplicatedMergeTree.cpp:2349: DB::StorageReplicatedMergeTree::executeLogEntry(DB::ReplicatedMergeTreeLogEntry&) @ 0x0000000015eba91b 20. /build/src/Storages/StorageReplicatedMergeTree.cpp:3876: bool std::__function::__policy_invoker&)>::__call_impl[abi:se190107])::$_1, bool (std::shared_ptr&)>>(std::__function::__policy_storage const*, std::shared_ptr&) @ 0x0000000015f9837e 21. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000165d6fc3 22. /build/src/Storages/StorageReplicatedMergeTree.cpp:3872: DB::StorageReplicatedMergeTree::processQueueEntry(std::shared_ptr) @ 0x0000000015efc18a 23. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001624c1b2 24. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000162f9c70 25. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x00000000162fa55a 26. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc6653 27. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000000fccc4c3 28. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc3d92 29. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fcca080 30. ? @ 0x00007fbc6213eac3 31. ? @ 0x00007fbc621d0850 (version 25.3.6.10636.altinitytest (altinity build)) 2025.07.28 12:02:17.685902 [ 62075 ] {49b8c6c4-c39b-497c-96ca-f6255ef7c4f2} executeQuery: Code: 394. DB::Exception: Query was cancelled. (QUERY_WAS_CANCELLED) (version 25.3.6.10636.altinitytest (altinity build)) (from [::1]:44788) (comment: 02461_cancel_finish_race.sh) (query 1, line 1) (in query: KILL QUERY WHERE current_database = 'test_dtwle8fg' SYNC FORMAT Null), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000000a074fcb 4. /build/src/Interpreters/ProcessList.cpp:567: DB::QueryStatus::throwQueryWasCancelled() const @ 0x0000000014a4bc85 5. /build/src/Interpreters/ProcessList.cpp:520: DB::QueryStatus::throwProperExceptionIfNeeded(unsigned long const&, unsigned long const&) @ 0x0000000014a4bbd9 6. /build/src/Interpreters/ProcessList.cpp:557: DB::QueryStatus::checkTimeLimit() @ 0x0000000014a4c2cd 7. /build/src/Processors/Executors/PipelineExecutor.cpp:206: DB::PipelineExecutor::finalizeExecution() @ 0x00000000169b13ba 8. /build/src/Processors/Executors/PipelineExecutor.cpp:153: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x00000000169b0584 9. /build/src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:se190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169bfeab 10. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc3d92 11. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fcca080 12. ? @ 0x00007fbc6213eac3 13. ? @ 0x00007fbc621d0850 2025.07.28 12:02:17.727970 [ 62075 ] {} TCPHandler: Code: 394. DB::Exception: Query was cancelled. (QUERY_WAS_CANCELLED), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000000a074fcb 4. /build/src/Interpreters/ProcessList.cpp:567: DB::QueryStatus::throwQueryWasCancelled() const @ 0x0000000014a4bc85 5. /build/src/Interpreters/ProcessList.cpp:520: DB::QueryStatus::throwProperExceptionIfNeeded(unsigned long const&, unsigned long const&) @ 0x0000000014a4bbd9 6. /build/src/Interpreters/ProcessList.cpp:557: DB::QueryStatus::checkTimeLimit() @ 0x0000000014a4c2cd 7. /build/src/Processors/Executors/PipelineExecutor.cpp:206: DB::PipelineExecutor::finalizeExecution() @ 0x00000000169b13ba 8. /build/src/Processors/Executors/PipelineExecutor.cpp:153: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x00000000169b0584 9. /build/src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:se190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169bfeab 10. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc3d92 11. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fcca080 12. ? @ 0x00007fbc6213eac3 13. ? @ 0x00007fbc621d0850 Job's origin stack trace: 0. /build/src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000000fc33b84 1. /build/src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000000fcc2ea7 2. /build/src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fcc535c 3. /build/src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000000fcc584d 4. /build/src/Common/ThreadPool.h:279: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x00000000169bf193 5. /build/src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x00000000169bf518 6. /build/src/Server/TCPHandler.cpp:1237: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x00000000168f1525 7. /build/src/Server/TCPHandler.cpp:678: DB::TCPHandler::runImpl() @ 0x00000000168e68e5 8. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 9. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 10. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 11. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 12. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 13. ? @ 0x00007fbc6213eac3 14. ? @ 0x00007fbc621d0850 2025.07.28 12:02:17.739321 [ 3966 ] {} test_13.rmt2 (7f9b740d-015c-470e-8cc6-8ba33be0dc63): auto DB::StorageReplicatedMergeTree::processQueueEntry(ReplicatedMergeTreeQueue::SelectedEntryPtr)::(anonymous class)::operator()(LogEntryPtr &) const: Code: 86. DB::HTTPException: Received error from remote server http://146b4357c08d:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Ftest%2F01165%2Ftest_13%2Frmt%2Freplicas%2F1&part=20250728_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.6.10636.altinitytest (altinity build)) '. (RECEIVED_ERROR_FROM_REMOTE_IO_SERVER), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.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 const&, int&&, String const&, unsigned long&&, String const&) @ 0x000000000feda8d9 4. /build/src/IO/HTTPCommon.cpp:104: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x000000000feda6e2 5. /build/src/IO/HTTPCommon.cpp:93: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x000000000feda537 6. /build/src/IO/ReadWriteBufferFromHTTP.cpp:277: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x000000001184a4c4 7. /build/src/IO/ReadWriteBufferFromHTTP.cpp:285: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x000000001184a615 8. /build/src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x000000001184ae59 9. /build/src/IO/ReadWriteBufferFromHTTP.cpp:472: void std::__function::__policy_invoker::__call_impl[abi:se190107]>(std::__function::__policy_storage const*) @ 0x000000001184cedd 10. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001184858b 11. /build/src/IO/ReadWriteBufferFromHTTP.cpp:465: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x000000001184bf0b 12. /build/src/IO/ReadBuffer.h:60: DB::ReadBuffer::next() @ 0x000000000a148c7b 13. /build/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) @ 0x0000000011849fb2 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]>&)>&, 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&) @ 0x0000000011841980 15. /build/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) @ 0x000000001621208e 16. /build/src/Storages/StorageReplicatedMergeTree.cpp:5228: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl[abi:se190107] const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000015f9a5fe 17. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000015ed8bfd 18. /build/src/Storages/StorageReplicatedMergeTree.cpp:2514: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x0000000015ec9aab 19. /build/src/Storages/StorageReplicatedMergeTree.cpp:2349: DB::StorageReplicatedMergeTree::executeLogEntry(DB::ReplicatedMergeTreeLogEntry&) @ 0x0000000015eba91b 20. /build/src/Storages/StorageReplicatedMergeTree.cpp:3876: bool std::__function::__policy_invoker&)>::__call_impl[abi:se190107])::$_1, bool (std::shared_ptr&)>>(std::__function::__policy_storage const*, std::shared_ptr&) @ 0x0000000015f9837e 21. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000165d6fc3 22. /build/src/Storages/StorageReplicatedMergeTree.cpp:3872: DB::StorageReplicatedMergeTree::processQueueEntry(std::shared_ptr) @ 0x0000000015efc18a 23. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001624c1b2 24. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000162f9c70 25. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x00000000162fa55a 26. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc6653 27. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000000fccc4c3 28. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc3d92 29. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fcca080 30. ? @ 0x00007fbc6213eac3 31. ? @ 0x00007fbc621d0850 (version 25.3.6.10636.altinitytest (altinity build)) 2025.07.28 12:02:17.764336 [ 17255 ] {d1ca1a6a-0bb5-4b86-a68a-63851fdcd883} executeQuery: Code: 394. DB::Exception: Query was cancelled. (QUERY_WAS_CANCELLED) (version 25.3.6.10636.altinitytest (altinity build)) (from [::1]:44794) (comment: 02461_cancel_finish_race.sh) (query 1, line 1) (in query: KILL QUERY WHERE current_database = 'test_dtwle8fg' SYNC FORMAT Null), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000000a074fcb 4. /build/src/Interpreters/ProcessList.cpp:567: DB::QueryStatus::throwQueryWasCancelled() const @ 0x0000000014a4bc85 5. /build/src/Interpreters/ProcessList.cpp:520: DB::QueryStatus::throwProperExceptionIfNeeded(unsigned long const&, unsigned long const&) @ 0x0000000014a4bbd9 6. /build/src/Interpreters/ProcessList.cpp:557: DB::QueryStatus::checkTimeLimit() @ 0x0000000014a4c2cd 7. /build/src/Processors/Executors/PipelineExecutor.cpp:206: DB::PipelineExecutor::finalizeExecution() @ 0x00000000169b13ba 8. /build/src/Processors/Executors/PipelineExecutor.cpp:153: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x00000000169b0584 9. /build/src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:se190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169bfeab 10. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc3d92 11. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fcca080 12. ? @ 0x00007fbc6213eac3 13. ? @ 0x00007fbc621d0850 2025.07.28 12:02:17.789522 [ 7625 ] {} TCPHandler: Code: 394. DB::Exception: Query was cancelled. (QUERY_WAS_CANCELLED), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000000a074fcb 4. /build/src/Interpreters/ProcessList.cpp:567: DB::QueryStatus::throwQueryWasCancelled() const @ 0x0000000014a4bc85 5. /build/src/Interpreters/ProcessList.cpp:520: DB::QueryStatus::throwProperExceptionIfNeeded(unsigned long const&, unsigned long const&) @ 0x0000000014a4bbd9 6. /build/src/Interpreters/ProcessList.cpp:557: DB::QueryStatus::checkTimeLimit() @ 0x0000000014a4c2cd 7. /build/src/Processors/Executors/PipelineExecutor.cpp:206: DB::PipelineExecutor::finalizeExecution() @ 0x00000000169b13ba 8. /build/src/Processors/Executors/PipelineExecutor.cpp:181: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x00000000169b1726 9. /build/src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x00000000169c081c 10. /build/src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x00000000169c0978 11. /build/src/Interpreters/InterpreterKillQueryQuery.cpp:442: DB::InterpreterKillQueryQuery::getSelectResult(String const&, String const&) @ 0x0000000014cf0f6b 12. /build/src/Interpreters/InterpreterKillQueryQuery.cpp:222: DB::InterpreterKillQueryQuery::execute() @ 0x0000000014cebde2 13. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88dc9 14. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 15. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 16. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 17. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 18. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 19. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 20. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 21. ? @ 0x00007fbc6213eac3 22. ? @ 0x00007fbc621d0850 2025.07.28 12:02:17.800012 [ 17255 ] {} TCPHandler: Code: 394. DB::Exception: Query was cancelled. (QUERY_WAS_CANCELLED), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000000a074fcb 4. /build/src/Interpreters/ProcessList.cpp:567: DB::QueryStatus::throwQueryWasCancelled() const @ 0x0000000014a4bc85 5. /build/src/Interpreters/ProcessList.cpp:520: DB::QueryStatus::throwProperExceptionIfNeeded(unsigned long const&, unsigned long const&) @ 0x0000000014a4bbd9 6. /build/src/Interpreters/ProcessList.cpp:557: DB::QueryStatus::checkTimeLimit() @ 0x0000000014a4c2cd 7. /build/src/Processors/Executors/PipelineExecutor.cpp:206: DB::PipelineExecutor::finalizeExecution() @ 0x00000000169b13ba 8. /build/src/Processors/Executors/PipelineExecutor.cpp:153: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x00000000169b0584 9. /build/src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:se190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169bfeab 10. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc3d92 11. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fcca080 12. ? @ 0x00007fbc6213eac3 13. ? @ 0x00007fbc621d0850 Job's origin stack trace: 0. /build/src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000000fc33b84 1. /build/src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000000fcc2ea7 2. /build/src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fcc535c 3. /build/src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000000fcc584d 4. /build/src/Common/ThreadPool.h:279: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x00000000169bf193 5. /build/src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x00000000169bf518 6. /build/src/Server/TCPHandler.cpp:1237: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x00000000168f1525 7. /build/src/Server/TCPHandler.cpp:678: DB::TCPHandler::runImpl() @ 0x00000000168e68e5 8. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 9. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 10. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 11. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 12. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 13. ? @ 0x00007fbc6213eac3 14. ? @ 0x00007fbc621d0850 2025.07.28 12:02:17.802650 [ 62057 ] {} TCPHandler: Code: 394. DB::Exception: Query was cancelled. (QUERY_WAS_CANCELLED), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000000a074fcb 4. /build/src/Interpreters/ProcessList.cpp:567: DB::QueryStatus::throwQueryWasCancelled() const @ 0x0000000014a4bc85 5. /build/src/Interpreters/ProcessList.cpp:520: DB::QueryStatus::throwProperExceptionIfNeeded(unsigned long const&, unsigned long const&) @ 0x0000000014a4bbd9 6. /build/src/Interpreters/ProcessList.cpp:531: DB::QueryStatus::addPipelineExecutor(DB::PipelineExecutor*) @ 0x0000000014a4bd9c 7. /build/src/Processors/Executors/PipelineExecutor.cpp:73: DB::PipelineExecutor::PipelineExecutor(std::shared_ptr, std::allocator>>>&, std::shared_ptr) @ 0x00000000169afe31 8. /build/contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x00000000169c07b5 9. /build/src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x00000000169c0978 10. /build/src/Interpreters/InterpreterKillQueryQuery.cpp:439: DB::InterpreterKillQueryQuery::getSelectResult(String const&, String const&) @ 0x0000000014cf0f04 11. /build/src/Interpreters/InterpreterKillQueryQuery.cpp:222: DB::InterpreterKillQueryQuery::execute() @ 0x0000000014cebde2 12. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88dc9 13. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 14. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 15. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 16. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 17. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 18. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 19. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 20. ? @ 0x00007fbc6213eac3 21. ? @ 0x00007fbc621d0850 2025.07.28 12:02:17.810158 [ 17203 ] {} TCPHandler: Code: 394. DB::Exception: Query was cancelled. (QUERY_WAS_CANCELLED), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000000a074fcb 4. /build/src/Interpreters/ProcessList.cpp:567: DB::QueryStatus::throwQueryWasCancelled() const @ 0x0000000014a4bc85 5. /build/src/Interpreters/ProcessList.cpp:520: DB::QueryStatus::throwProperExceptionIfNeeded(unsigned long const&, unsigned long const&) @ 0x0000000014a4bbd9 6. /build/src/Interpreters/ProcessList.cpp:557: DB::QueryStatus::checkTimeLimit() @ 0x0000000014a4c2cd 7. /build/src/Processors/Executors/PipelineExecutor.cpp:206: DB::PipelineExecutor::finalizeExecution() @ 0x00000000169b13ba 8. /build/src/Processors/Executors/PipelineExecutor.cpp:181: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x00000000169b1726 9. /build/src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x00000000169c081c 10. /build/src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x00000000169c0978 11. /build/src/Interpreters/InterpreterKillQueryQuery.cpp:439: DB::InterpreterKillQueryQuery::getSelectResult(String const&, String const&) @ 0x0000000014cf0f04 12. /build/src/Interpreters/InterpreterKillQueryQuery.cpp:222: DB::InterpreterKillQueryQuery::execute() @ 0x0000000014cebde2 13. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88dc9 14. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 15. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 16. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 17. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 18. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 19. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 20. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 21. ? @ 0x00007fbc6213eac3 22. ? @ 0x00007fbc621d0850 2025.07.28 12:02:18.168590 [ 3971 ] {} test_13.rmt2 (7f9b740d-015c-470e-8cc6-8ba33be0dc63): auto DB::StorageReplicatedMergeTree::processQueueEntry(ReplicatedMergeTreeQueue::SelectedEntryPtr)::(anonymous class)::operator()(LogEntryPtr &) const: Code: 86. DB::HTTPException: Received error from remote server http://146b4357c08d:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Ftest%2F01165%2Ftest_13%2Frmt%2Freplicas%2F1&part=20250728_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.6.10636.altinitytest (altinity build)) '. (RECEIVED_ERROR_FROM_REMOTE_IO_SERVER), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.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 const&, int&&, String const&, unsigned long&&, String const&) @ 0x000000000feda8d9 4. /build/src/IO/HTTPCommon.cpp:104: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x000000000feda6e2 5. /build/src/IO/HTTPCommon.cpp:93: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x000000000feda537 6. /build/src/IO/ReadWriteBufferFromHTTP.cpp:277: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x000000001184a4c4 7. /build/src/IO/ReadWriteBufferFromHTTP.cpp:285: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x000000001184a615 8. /build/src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x000000001184ae59 9. /build/src/IO/ReadWriteBufferFromHTTP.cpp:472: void std::__function::__policy_invoker::__call_impl[abi:se190107]>(std::__function::__policy_storage const*) @ 0x000000001184cedd 10. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001184858b 11. /build/src/IO/ReadWriteBufferFromHTTP.cpp:465: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x000000001184bf0b 12. /build/src/IO/ReadBuffer.h:60: DB::ReadBuffer::next() @ 0x000000000a148c7b 13. /build/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) @ 0x0000000011849fb2 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]>&)>&, 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&) @ 0x0000000011841980 15. /build/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) @ 0x000000001621208e 16. /build/src/Storages/StorageReplicatedMergeTree.cpp:5228: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl[abi:se190107] const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000015f9a5fe 17. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000015ed8bfd 18. /build/src/Storages/StorageReplicatedMergeTree.cpp:2514: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x0000000015ec9aab 19. /build/src/Storages/StorageReplicatedMergeTree.cpp:2349: DB::StorageReplicatedMergeTree::executeLogEntry(DB::ReplicatedMergeTreeLogEntry&) @ 0x0000000015eba91b 20. /build/src/Storages/StorageReplicatedMergeTree.cpp:3876: bool std::__function::__policy_invoker&)>::__call_impl[abi:se190107])::$_1, bool (std::shared_ptr&)>>(std::__function::__policy_storage const*, std::shared_ptr&) @ 0x0000000015f9837e 21. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000165d6fc3 22. /build/src/Storages/StorageReplicatedMergeTree.cpp:3872: DB::StorageReplicatedMergeTree::processQueueEntry(std::shared_ptr) @ 0x0000000015efc18a 23. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001624c1b2 24. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000162f9c70 25. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x00000000162fa55a 26. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc6653 27. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000000fccc4c3 28. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc3d92 29. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fcca080 30. ? @ 0x00007fbc6213eac3 31. ? @ 0x00007fbc621d0850 (version 25.3.6.10636.altinitytest (altinity build)) 2025.07.28 12:02:18.238562 [ 62058 ] {0e7a57eb-fa1b-4658-8387-392a71aeea2a} executeQuery: Code: 394. DB::Exception: Query was cancelled. (QUERY_WAS_CANCELLED) (version 25.3.6.10636.altinitytest (altinity build)) (from [::1]:44966) (comment: 02461_cancel_finish_race.sh) (query 1, line 1) (in query: KILL QUERY WHERE current_database = 'test_dtwle8fg' SYNC FORMAT Null), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000000a074fcb 4. /build/src/Interpreters/ProcessList.cpp:567: DB::QueryStatus::throwQueryWasCancelled() const @ 0x0000000014a4bc85 5. /build/src/Interpreters/ProcessList.cpp:520: DB::QueryStatus::throwProperExceptionIfNeeded(unsigned long const&, unsigned long const&) @ 0x0000000014a4bbd9 6. /build/src/Interpreters/ProcessList.cpp:557: DB::QueryStatus::checkTimeLimit() @ 0x0000000014a4c2cd 7. /build/src/Processors/Executors/PipelineExecutor.cpp:206: DB::PipelineExecutor::finalizeExecution() @ 0x00000000169b13ba 8. /build/src/Processors/Executors/PipelineExecutor.cpp:153: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x00000000169b0584 9. /build/src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:se190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169bfeab 10. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc3d92 11. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fcca080 12. ? @ 0x00007fbc6213eac3 13. ? @ 0x00007fbc621d0850 2025.07.28 12:02:18.259660 [ 62058 ] {} TCPHandler: Code: 394. DB::Exception: Query was cancelled. (QUERY_WAS_CANCELLED), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000000a074fcb 4. /build/src/Interpreters/ProcessList.cpp:567: DB::QueryStatus::throwQueryWasCancelled() const @ 0x0000000014a4bc85 5. /build/src/Interpreters/ProcessList.cpp:520: DB::QueryStatus::throwProperExceptionIfNeeded(unsigned long const&, unsigned long const&) @ 0x0000000014a4bbd9 6. /build/src/Interpreters/ProcessList.cpp:557: DB::QueryStatus::checkTimeLimit() @ 0x0000000014a4c2cd 7. /build/src/Processors/Executors/PipelineExecutor.cpp:206: DB::PipelineExecutor::finalizeExecution() @ 0x00000000169b13ba 8. /build/src/Processors/Executors/PipelineExecutor.cpp:153: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x00000000169b0584 9. /build/src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:se190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169bfeab 10. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc3d92 11. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fcca080 12. ? @ 0x00007fbc6213eac3 13. ? @ 0x00007fbc621d0850 Job's origin stack trace: 0. /build/src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000000fc33b84 1. /build/src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000000fcc2ea7 2. /build/src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fcc535c 3. /build/src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000000fcc584d 4. /build/src/Common/ThreadPool.h:279: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x00000000169bf193 5. /build/src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x00000000169bf518 6. /build/src/Server/TCPHandler.cpp:1237: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x00000000168f1525 7. /build/src/Server/TCPHandler.cpp:678: DB::TCPHandler::runImpl() @ 0x00000000168e68e5 8. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 9. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 10. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 11. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 12. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 13. ? @ 0x00007fbc6213eac3 14. ? @ 0x00007fbc621d0850 2025.07.28 12:02:18.315604 [ 4446 ] {8c578ce0-2cd2-4600-9caa-9024ac76d4a9} executeQuery: Code: 394. DB::Exception: Query was cancelled. (QUERY_WAS_CANCELLED) (version 25.3.6.10636.altinitytest (altinity build)) (from [::1]:44994) (comment: 02461_cancel_finish_race.sh) (query 1, line 1) (in query: KILL QUERY WHERE current_database = 'test_dtwle8fg' SYNC FORMAT Null), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000000a074fcb 4. /build/src/Interpreters/ProcessList.cpp:567: DB::QueryStatus::throwQueryWasCancelled() const @ 0x0000000014a4bc85 5. /build/src/Interpreters/ProcessList.cpp:520: DB::QueryStatus::throwProperExceptionIfNeeded(unsigned long const&, unsigned long const&) @ 0x0000000014a4bbd9 6. /build/src/Interpreters/ProcessList.cpp:557: DB::QueryStatus::checkTimeLimit() @ 0x0000000014a4c2cd 7. /build/src/Processors/Executors/PipelineExecutor.cpp:206: DB::PipelineExecutor::finalizeExecution() @ 0x00000000169b13ba 8. /build/src/Processors/Executors/PipelineExecutor.cpp:153: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x00000000169b0584 9. /build/src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:se190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169bfeab 10. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc3d92 11. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fcca080 12. ? @ 0x00007fbc6213eac3 13. ? @ 0x00007fbc621d0850 2025.07.28 12:02:18.332245 [ 62103 ] {7a308c75-fd46-4880-b93f-fadd17d74ce7} executeQuery: Code: 394. DB::Exception: Query was cancelled. (QUERY_WAS_CANCELLED) (version 25.3.6.10636.altinitytest (altinity build)) (from [::1]:45042) (comment: 02461_cancel_finish_race.sh) (query 1, line 1) (in query: KILL QUERY WHERE current_database = 'test_dtwle8fg' SYNC FORMAT Null), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000000a074fcb 4. /build/src/Interpreters/ProcessList.cpp:567: DB::QueryStatus::throwQueryWasCancelled() const @ 0x0000000014a4bc85 5. /build/src/Interpreters/ProcessList.cpp:520: DB::QueryStatus::throwProperExceptionIfNeeded(unsigned long const&, unsigned long const&) @ 0x0000000014a4bbd9 6. /build/src/Interpreters/ProcessList.cpp:557: DB::QueryStatus::checkTimeLimit() @ 0x0000000014a4c2cd 7. /build/src/Processors/Executors/PipelineExecutor.cpp:206: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x00000000169b03a3 8. /build/src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:se190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169bfeab 9. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc3d92 10. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fcca080 11. ? @ 0x00007fbc6213eac3 12. ? @ 0x00007fbc621d0850 2025.07.28 12:02:18.340360 [ 4446 ] {} TCPHandler: Code: 394. DB::Exception: Query was cancelled. (QUERY_WAS_CANCELLED), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000000a074fcb 4. /build/src/Interpreters/ProcessList.cpp:567: DB::QueryStatus::throwQueryWasCancelled() const @ 0x0000000014a4bc85 5. /build/src/Interpreters/ProcessList.cpp:520: DB::QueryStatus::throwProperExceptionIfNeeded(unsigned long const&, unsigned long const&) @ 0x0000000014a4bbd9 6. /build/src/Interpreters/ProcessList.cpp:557: DB::QueryStatus::checkTimeLimit() @ 0x0000000014a4c2cd 7. /build/src/Processors/Executors/PipelineExecutor.cpp:206: DB::PipelineExecutor::finalizeExecution() @ 0x00000000169b13ba 8. /build/src/Processors/Executors/PipelineExecutor.cpp:153: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x00000000169b0584 9. /build/src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:se190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169bfeab 10. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc3d92 11. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fcca080 12. ? @ 0x00007fbc6213eac3 13. ? @ 0x00007fbc621d0850 Job's origin stack trace: 0. /build/src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000000fc33b84 1. /build/src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000000fcc2ea7 2. /build/src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fcc535c 3. /build/src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000000fcc584d 4. /build/src/Common/ThreadPool.h:279: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x00000000169bf193 5. /build/src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x00000000169bf518 6. /build/src/Server/TCPHandler.cpp:1237: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x00000000168f1525 7. /build/src/Server/TCPHandler.cpp:678: DB::TCPHandler::runImpl() @ 0x00000000168e68e5 8. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 9. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 10. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 11. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 12. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 13. ? @ 0x00007fbc6213eac3 14. ? @ 0x00007fbc621d0850 2025.07.28 12:02:18.349039 [ 7625 ] {46deb7aa-cc14-4e26-98ac-2ebaed85fd0b} executeQuery: Code: 394. DB::Exception: Query was cancelled. (QUERY_WAS_CANCELLED) (version 25.3.6.10636.altinitytest (altinity build)) (from [::1]:45030) (comment: 02461_cancel_finish_race.sh) (query 1, line 1) (in query: KILL QUERY WHERE current_database = 'test_dtwle8fg' SYNC FORMAT Null), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000000a074fcb 4. /build/src/Interpreters/ProcessList.cpp:567: DB::QueryStatus::throwQueryWasCancelled() const @ 0x0000000014a4bc85 5. /build/src/Interpreters/ProcessList.cpp:520: DB::QueryStatus::throwProperExceptionIfNeeded(unsigned long const&, unsigned long const&) @ 0x0000000014a4bbd9 6. /build/src/Interpreters/ProcessList.cpp:557: DB::QueryStatus::checkTimeLimit() @ 0x0000000014a4c2cd 7. /build/src/Processors/Executors/PipelineExecutor.cpp:206: DB::PipelineExecutor::finalizeExecution() @ 0x00000000169b13ba 8. /build/src/Processors/Executors/PipelineExecutor.cpp:153: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x00000000169b0584 9. /build/src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:se190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169bfeab 10. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc3d92 11. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fcca080 12. ? @ 0x00007fbc6213eac3 13. ? @ 0x00007fbc621d0850 2025.07.28 12:02:18.359971 [ 62103 ] {} TCPHandler: Code: 394. DB::Exception: Query was cancelled. (QUERY_WAS_CANCELLED), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000000a074fcb 4. /build/src/Interpreters/ProcessList.cpp:567: DB::QueryStatus::throwQueryWasCancelled() const @ 0x0000000014a4bc85 5. /build/src/Interpreters/ProcessList.cpp:520: DB::QueryStatus::throwProperExceptionIfNeeded(unsigned long const&, unsigned long const&) @ 0x0000000014a4bbd9 6. /build/src/Interpreters/ProcessList.cpp:557: DB::QueryStatus::checkTimeLimit() @ 0x0000000014a4c2cd 7. /build/src/Processors/Executors/PipelineExecutor.cpp:206: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x00000000169b03a3 8. /build/src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:se190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169bfeab 9. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc3d92 10. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fcca080 11. ? @ 0x00007fbc6213eac3 12. ? @ 0x00007fbc621d0850 Job's origin stack trace: 0. /build/src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000000fc33b84 1. /build/src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000000fcc2ea7 2. /build/src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fcc535c 3. /build/src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000000fcc584d 4. /build/src/Common/ThreadPool.h:279: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x00000000169bf193 5. /build/src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x00000000169bf518 6. /build/src/Server/TCPHandler.cpp:1237: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x00000000168f1525 7. /build/src/Server/TCPHandler.cpp:678: DB::TCPHandler::runImpl() @ 0x00000000168e68e5 8. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 9. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 10. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 11. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 12. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 13. ? @ 0x00007fbc6213eac3 14. ? @ 0x00007fbc621d0850 2025.07.28 12:02:18.367861 [ 7625 ] {} TCPHandler: Code: 394. DB::Exception: Query was cancelled. (QUERY_WAS_CANCELLED), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000000a074fcb 4. /build/src/Interpreters/ProcessList.cpp:567: DB::QueryStatus::throwQueryWasCancelled() const @ 0x0000000014a4bc85 5. /build/src/Interpreters/ProcessList.cpp:520: DB::QueryStatus::throwProperExceptionIfNeeded(unsigned long const&, unsigned long const&) @ 0x0000000014a4bbd9 6. /build/src/Interpreters/ProcessList.cpp:557: DB::QueryStatus::checkTimeLimit() @ 0x0000000014a4c2cd 7. /build/src/Processors/Executors/PipelineExecutor.cpp:206: DB::PipelineExecutor::finalizeExecution() @ 0x00000000169b13ba 8. /build/src/Processors/Executors/PipelineExecutor.cpp:153: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x00000000169b0584 9. /build/src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:se190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169bfeab 10. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc3d92 11. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fcca080 12. ? @ 0x00007fbc6213eac3 13. ? @ 0x00007fbc621d0850 Job's origin stack trace: 0. /build/src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000000fc33b84 1. /build/src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000000fcc2ea7 2. /build/src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fcc535c 3. /build/src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000000fcc584d 4. /build/src/Common/ThreadPool.h:279: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x00000000169bf193 5. /build/src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x00000000169bf518 6. /build/src/Server/TCPHandler.cpp:1237: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x00000000168f1525 7. /build/src/Server/TCPHandler.cpp:678: DB::TCPHandler::runImpl() @ 0x00000000168e68e5 8. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 9. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 10. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 11. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 12. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 13. ? @ 0x00007fbc6213eac3 14. ? @ 0x00007fbc621d0850 2025.07.28 12:02:18.410158 [ 62075 ] {23822280-fa92-49d3-b0e3-6436a56081d8} executeQuery: Code: 394. DB::Exception: Query was cancelled. (QUERY_WAS_CANCELLED) (version 25.3.6.10636.altinitytest (altinity build)) (from [::1]:45074) (comment: 02461_cancel_finish_race.sh) (query 1, line 1) (in query: KILL QUERY WHERE current_database = 'test_dtwle8fg' SYNC FORMAT Null), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000000a074fcb 4. /build/src/Interpreters/ProcessList.cpp:567: DB::QueryStatus::throwQueryWasCancelled() const @ 0x0000000014a4bc85 5. /build/src/Interpreters/ProcessList.cpp:520: DB::QueryStatus::throwProperExceptionIfNeeded(unsigned long const&, unsigned long const&) @ 0x0000000014a4bbd9 6. /build/src/Interpreters/ProcessList.cpp:557: DB::QueryStatus::checkTimeLimit() @ 0x0000000014a4c2cd 7. /build/src/Processors/Executors/PipelineExecutor.cpp:206: DB::PipelineExecutor::finalizeExecution() @ 0x00000000169b13ba 8. /build/src/Processors/Executors/PipelineExecutor.cpp:153: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x00000000169b0584 9. /build/src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:se190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169bfeab 10. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc3d92 11. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fcca080 12. ? @ 0x00007fbc6213eac3 13. ? @ 0x00007fbc621d0850 2025.07.28 12:02:18.433466 [ 62075 ] {} TCPHandler: Code: 394. DB::Exception: Query was cancelled. (QUERY_WAS_CANCELLED), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000000a074fcb 4. /build/src/Interpreters/ProcessList.cpp:567: DB::QueryStatus::throwQueryWasCancelled() const @ 0x0000000014a4bc85 5. /build/src/Interpreters/ProcessList.cpp:520: DB::QueryStatus::throwProperExceptionIfNeeded(unsigned long const&, unsigned long const&) @ 0x0000000014a4bbd9 6. /build/src/Interpreters/ProcessList.cpp:557: DB::QueryStatus::checkTimeLimit() @ 0x0000000014a4c2cd 7. /build/src/Processors/Executors/PipelineExecutor.cpp:206: DB::PipelineExecutor::finalizeExecution() @ 0x00000000169b13ba 8. /build/src/Processors/Executors/PipelineExecutor.cpp:153: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x00000000169b0584 9. /build/src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:se190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169bfeab 10. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc3d92 11. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fcca080 12. ? @ 0x00007fbc6213eac3 13. ? @ 0x00007fbc621d0850 Job's origin stack trace: 0. /build/src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000000fc33b84 1. /build/src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000000fcc2ea7 2. /build/src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fcc535c 3. /build/src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000000fcc584d 4. /build/src/Common/ThreadPool.h:279: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x00000000169bf193 5. /build/src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x00000000169bf518 6. /build/src/Server/TCPHandler.cpp:1237: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x00000000168f1525 7. /build/src/Server/TCPHandler.cpp:678: DB::TCPHandler::runImpl() @ 0x00000000168e68e5 8. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 9. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 10. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 11. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 12. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 13. ? @ 0x00007fbc6213eac3 14. ? @ 0x00007fbc621d0850 2025.07.28 12:02:18.504823 [ 62093 ] {145af7d0-08f2-4c91-b93a-f4f7704e66de} executeQuery: Code: 394. DB::Exception: Query was cancelled. (QUERY_WAS_CANCELLED) (version 25.3.6.10636.altinitytest (altinity build)) (from [::1]:45040) (comment: 02461_cancel_finish_race.sh) (query 1, line 1) (in query: KILL QUERY WHERE current_database = 'test_dtwle8fg' SYNC FORMAT Null), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000000a074fcb 4. /build/src/Interpreters/ProcessList.cpp:567: DB::QueryStatus::throwQueryWasCancelled() const @ 0x0000000014a4bc85 5. /build/src/Interpreters/ProcessList.cpp:520: DB::QueryStatus::throwProperExceptionIfNeeded(unsigned long const&, unsigned long const&) @ 0x0000000014a4bbd9 6. /build/src/Interpreters/ProcessList.cpp:557: DB::QueryStatus::checkTimeLimit() @ 0x0000000014a4c2cd 7. /build/src/Processors/Executors/PipelineExecutor.cpp:206: DB::PipelineExecutor::finalizeExecution() @ 0x00000000169b13ba 8. /build/src/Processors/Executors/PipelineExecutor.cpp:153: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x00000000169b0584 9. /build/src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:se190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169bfeab 10. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc3d92 11. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fcca080 12. ? @ 0x00007fbc6213eac3 13. ? @ 0x00007fbc621d0850 2025.07.28 12:02:18.525039 [ 17256 ] {} TCPHandler: Code: 394. DB::Exception: Query was cancelled. (QUERY_WAS_CANCELLED), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000000a074fcb 4. /build/src/Interpreters/ProcessList.cpp:567: DB::QueryStatus::throwQueryWasCancelled() const @ 0x0000000014a4bc85 5. /build/src/Interpreters/ProcessList.cpp:520: DB::QueryStatus::throwProperExceptionIfNeeded(unsigned long const&, unsigned long const&) @ 0x0000000014a4bbd9 6. /build/src/Interpreters/ProcessList.cpp:557: DB::QueryStatus::checkTimeLimit() @ 0x0000000014a4c2cd 7. /build/src/Processors/Executors/PipelineExecutor.cpp:206: DB::PipelineExecutor::finalizeExecution() @ 0x00000000169b13ba 8. /build/src/Processors/Executors/PipelineExecutor.cpp:181: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x00000000169b1726 9. /build/src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x00000000169c081c 10. /build/src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x00000000169c0978 11. /build/src/Interpreters/InterpreterKillQueryQuery.cpp:439: DB::InterpreterKillQueryQuery::getSelectResult(String const&, String const&) @ 0x0000000014cf0f04 12. /build/src/Interpreters/InterpreterKillQueryQuery.cpp:222: DB::InterpreterKillQueryQuery::execute() @ 0x0000000014cebde2 13. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88dc9 14. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 15. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 16. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 17. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 18. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 19. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 20. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 21. ? @ 0x00007fbc6213eac3 22. ? @ 0x00007fbc621d0850 2025.07.28 12:02:18.526125 [ 62093 ] {} TCPHandler: Code: 394. DB::Exception: Query was cancelled. (QUERY_WAS_CANCELLED), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000000a074fcb 4. /build/src/Interpreters/ProcessList.cpp:567: DB::QueryStatus::throwQueryWasCancelled() const @ 0x0000000014a4bc85 5. /build/src/Interpreters/ProcessList.cpp:520: DB::QueryStatus::throwProperExceptionIfNeeded(unsigned long const&, unsigned long const&) @ 0x0000000014a4bbd9 6. /build/src/Interpreters/ProcessList.cpp:557: DB::QueryStatus::checkTimeLimit() @ 0x0000000014a4c2cd 7. /build/src/Processors/Executors/PipelineExecutor.cpp:206: DB::PipelineExecutor::finalizeExecution() @ 0x00000000169b13ba 8. /build/src/Processors/Executors/PipelineExecutor.cpp:153: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x00000000169b0584 9. /build/src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:se190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169bfeab 10. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc3d92 11. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fcca080 12. ? @ 0x00007fbc6213eac3 13. ? @ 0x00007fbc621d0850 Job's origin stack trace: 0. /build/src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000000fc33b84 1. /build/src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000000fcc2ea7 2. /build/src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fcc535c 3. /build/src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000000fcc584d 4. /build/src/Common/ThreadPool.h:279: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x00000000169bf193 5. /build/src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x00000000169bf518 6. /build/src/Server/TCPHandler.cpp:1237: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x00000000168f1525 7. /build/src/Server/TCPHandler.cpp:678: DB::TCPHandler::runImpl() @ 0x00000000168e68e5 8. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 9. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 10. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 11. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 12. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 13. ? @ 0x00007fbc6213eac3 14. ? @ 0x00007fbc621d0850 2025.07.28 12:02:18.598215 [ 17611 ] {test_7r61jzpt_test_02585_query_to_kill_id_1} executeQuery: Code: 394. DB::Exception: Query was cancelled. (QUERY_WAS_CANCELLED) (version 25.3.6.10636.altinitytest (altinity build)) (from [::1]:60174) (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. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000000a074fcb 4. /build/src/Interpreters/ProcessList.cpp:567: DB::QueryStatus::throwQueryWasCancelled() const @ 0x0000000014a4bc85 5. /build/src/Interpreters/ProcessList.cpp:520: DB::QueryStatus::throwProperExceptionIfNeeded(unsigned long const&, unsigned long const&) @ 0x0000000014a4bbd9 6. /build/src/Interpreters/ProcessList.cpp:557: DB::QueryStatus::checkTimeLimit() @ 0x0000000014a4c2cd 7. /build/src/Processors/Executors/PipelineExecutor.cpp:206: DB::PipelineExecutor::finalizeExecution() @ 0x00000000169b13ba 8. /build/src/Processors/Executors/PipelineExecutor.cpp:153: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x00000000169b0584 9. /build/src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:se190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169bfeab 10. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc3d92 11. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fcca080 12. ? @ 0x00007fbc6213eac3 13. ? @ 0x00007fbc621d0850 2025.07.28 12:02:18.717645 [ 17611 ] {} TCPHandler: Code: 394. DB::Exception: Query was cancelled. (QUERY_WAS_CANCELLED), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000000a074fcb 4. /build/src/Interpreters/ProcessList.cpp:567: DB::QueryStatus::throwQueryWasCancelled() const @ 0x0000000014a4bc85 5. /build/src/Interpreters/ProcessList.cpp:520: DB::QueryStatus::throwProperExceptionIfNeeded(unsigned long const&, unsigned long const&) @ 0x0000000014a4bbd9 6. /build/src/Interpreters/ProcessList.cpp:557: DB::QueryStatus::checkTimeLimit() @ 0x0000000014a4c2cd 7. /build/src/Processors/Executors/PipelineExecutor.cpp:206: DB::PipelineExecutor::finalizeExecution() @ 0x00000000169b13ba 8. /build/src/Processors/Executors/PipelineExecutor.cpp:153: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x00000000169b0584 9. /build/src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:se190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169bfeab 10. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc3d92 11. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fcca080 12. ? @ 0x00007fbc6213eac3 13. ? @ 0x00007fbc621d0850 Job's origin stack trace: 0. /build/src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000000fc33b84 1. /build/src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000000fcc2ea7 2. /build/src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fcc535c 3. /build/src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000000fcc584d 4. /build/src/Common/ThreadPool.h:279: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x00000000169bf193 5. /build/src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x00000000169bf518 6. /build/src/Server/TCPHandler.cpp:1237: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x00000000168f1525 7. /build/src/Server/TCPHandler.cpp:678: DB::TCPHandler::runImpl() @ 0x00000000168e68e5 8. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 9. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 10. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 11. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 12. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 13. ? @ 0x00007fbc6213eac3 14. ? @ 0x00007fbc621d0850 2025.07.28 12:02:18.753046 [ 62114 ] {97d2b494-50f9-43ba-9b16-46820ec6224b} executeQuery: Code: 394. DB::Exception: Query was cancelled. (QUERY_WAS_CANCELLED) (version 25.3.6.10636.altinitytest (altinity build)) (from [::1]:45194) (comment: 02461_cancel_finish_race.sh) (query 1, line 1) (in query: KILL QUERY WHERE current_database = 'test_dtwle8fg' SYNC FORMAT Null), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000000a074fcb 4. /build/src/Interpreters/ProcessList.cpp:567: DB::QueryStatus::throwQueryWasCancelled() const @ 0x0000000014a4bc85 5. /build/src/Interpreters/ProcessList.cpp:520: DB::QueryStatus::throwProperExceptionIfNeeded(unsigned long const&, unsigned long const&) @ 0x0000000014a4bbd9 6. /build/src/Interpreters/ProcessList.cpp:531: DB::QueryStatus::addPipelineExecutor(DB::PipelineExecutor*) @ 0x0000000014a4bd9c 7. /build/src/Processors/Executors/PipelineExecutor.cpp:73: DB::PipelineExecutor::PipelineExecutor(std::shared_ptr, std::allocator>>>&, std::shared_ptr) @ 0x00000000169afe31 8. /build/contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x00000000169bef66 9. /build/src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x00000000169bf518 10. /build/src/Server/TCPHandler.cpp:1237: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x00000000168f1525 11. /build/src/Server/TCPHandler.cpp:678: DB::TCPHandler::runImpl() @ 0x00000000168e68e5 12. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 13. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 14. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 16. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 17. ? @ 0x00007fbc6213eac3 18. ? @ 0x00007fbc621d0850 2025.07.28 12:02:18.765507 [ 3967 ] {} test_13.rmt2 (7f9b740d-015c-470e-8cc6-8ba33be0dc63): auto DB::StorageReplicatedMergeTree::processQueueEntry(ReplicatedMergeTreeQueue::SelectedEntryPtr)::(anonymous class)::operator()(LogEntryPtr &) const: Code: 86. DB::HTTPException: Received error from remote server http://146b4357c08d:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Ftest%2F01165%2Ftest_13%2Frmt%2Freplicas%2F1&part=20250728_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.6.10636.altinitytest (altinity build)) '. (RECEIVED_ERROR_FROM_REMOTE_IO_SERVER), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.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 const&, int&&, String const&, unsigned long&&, String const&) @ 0x000000000feda8d9 4. /build/src/IO/HTTPCommon.cpp:104: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x000000000feda6e2 5. /build/src/IO/HTTPCommon.cpp:93: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x000000000feda537 6. /build/src/IO/ReadWriteBufferFromHTTP.cpp:277: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x000000001184a4c4 7. /build/src/IO/ReadWriteBufferFromHTTP.cpp:285: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x000000001184a615 8. /build/src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x000000001184ae59 9. /build/src/IO/ReadWriteBufferFromHTTP.cpp:472: void std::__function::__policy_invoker::__call_impl[abi:se190107]>(std::__function::__policy_storage const*) @ 0x000000001184cedd 10. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001184858b 11. /build/src/IO/ReadWriteBufferFromHTTP.cpp:465: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x000000001184bf0b 12. /build/src/IO/ReadBuffer.h:60: DB::ReadBuffer::next() @ 0x000000000a148c7b 13. /build/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) @ 0x0000000011849fb2 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]>&)>&, 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&) @ 0x0000000011841980 15. /build/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) @ 0x000000001621208e 16. /build/src/Storages/StorageReplicatedMergeTree.cpp:5228: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl[abi:se190107] const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000015f9a5fe 17. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000015ed8bfd 18. /build/src/Storages/StorageReplicatedMergeTree.cpp:2514: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x0000000015ec9aab 19. /build/src/Storages/StorageReplicatedMergeTree.cpp:2349: DB::StorageReplicatedMergeTree::executeLogEntry(DB::ReplicatedMergeTreeLogEntry&) @ 0x0000000015eba91b 20. /build/src/Storages/StorageReplicatedMergeTree.cpp:3876: bool std::__function::__policy_invoker&)>::__call_impl[abi:se190107])::$_1, bool (std::shared_ptr&)>>(std::__function::__policy_storage const*, std::shared_ptr&) @ 0x0000000015f9837e 21. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000165d6fc3 22. /build/src/Storages/StorageReplicatedMergeTree.cpp:3872: DB::StorageReplicatedMergeTree::processQueueEntry(std::shared_ptr) @ 0x0000000015efc18a 23. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001624c1b2 24. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000162f9c70 25. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x00000000162fa55a 26. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc6653 27. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000000fccc4c3 28. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc3d92 29. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fcca080 30. ? @ 0x00007fbc6213eac3 31. ? @ 0x00007fbc621d0850 (version 25.3.6.10636.altinitytest (altinity build)) 2025.07.28 12:02:18.780673 [ 62114 ] {} TCPHandler: Code: 394. DB::Exception: Query was cancelled. (QUERY_WAS_CANCELLED), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000000a074fcb 4. /build/src/Interpreters/ProcessList.cpp:567: DB::QueryStatus::throwQueryWasCancelled() const @ 0x0000000014a4bc85 5. /build/src/Interpreters/ProcessList.cpp:520: DB::QueryStatus::throwProperExceptionIfNeeded(unsigned long const&, unsigned long const&) @ 0x0000000014a4bbd9 6. /build/src/Interpreters/ProcessList.cpp:531: DB::QueryStatus::addPipelineExecutor(DB::PipelineExecutor*) @ 0x0000000014a4bd9c 7. /build/src/Processors/Executors/PipelineExecutor.cpp:73: DB::PipelineExecutor::PipelineExecutor(std::shared_ptr, std::allocator>>>&, std::shared_ptr) @ 0x00000000169afe31 8. /build/contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x00000000169bef66 9. /build/src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x00000000169bf518 10. /build/src/Server/TCPHandler.cpp:1237: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x00000000168f1525 11. /build/src/Server/TCPHandler.cpp:678: DB::TCPHandler::runImpl() @ 0x00000000168e68e5 12. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 13. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 14. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 16. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 17. ? @ 0x00007fbc6213eac3 18. ? @ 0x00007fbc621d0850 2025.07.28 12:02:18.799242 [ 17203 ] {b50806ed-58f1-487a-a9c6-ce3eb1551951} executeQuery: Code: 394. DB::Exception: Query was cancelled. (QUERY_WAS_CANCELLED) (version 25.3.6.10636.altinitytest (altinity build)) (from [::1]:45198) (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. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000000a074fcb 4. /build/src/Interpreters/ProcessList.cpp:567: DB::QueryStatus::throwQueryWasCancelled() const @ 0x0000000014a4bc85 5. /build/src/Interpreters/ProcessList.cpp:520: DB::QueryStatus::throwProperExceptionIfNeeded(unsigned long const&, unsigned long const&) @ 0x0000000014a4bbd9 6. /build/src/Interpreters/ProcessList.cpp:557: DB::QueryStatus::checkTimeLimit() @ 0x0000000014a4c2cd 7. /build/src/Processors/Executors/PipelineExecutor.cpp:206: DB::PipelineExecutor::finalizeExecution() @ 0x00000000169b13ba 8. /build/src/Processors/Executors/PipelineExecutor.cpp:153: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x00000000169b0584 9. /build/src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:se190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169bfeab 10. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc3d92 11. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fcca080 12. ? @ 0x00007fbc6213eac3 13. ? @ 0x00007fbc621d0850 2025.07.28 12:02:18.803871 [ 17203 ] {} TCPHandler: Code: 394. DB::Exception: Query was cancelled. (QUERY_WAS_CANCELLED), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000000a074fcb 4. /build/src/Interpreters/ProcessList.cpp:567: DB::QueryStatus::throwQueryWasCancelled() const @ 0x0000000014a4bc85 5. /build/src/Interpreters/ProcessList.cpp:520: DB::QueryStatus::throwProperExceptionIfNeeded(unsigned long const&, unsigned long const&) @ 0x0000000014a4bbd9 6. /build/src/Interpreters/ProcessList.cpp:557: DB::QueryStatus::checkTimeLimit() @ 0x0000000014a4c2cd 7. /build/src/Processors/Executors/PipelineExecutor.cpp:206: DB::PipelineExecutor::finalizeExecution() @ 0x00000000169b13ba 8. /build/src/Processors/Executors/PipelineExecutor.cpp:153: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x00000000169b0584 9. /build/src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:se190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169bfeab 10. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc3d92 11. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fcca080 12. ? @ 0x00007fbc6213eac3 13. ? @ 0x00007fbc621d0850 Job's origin stack trace: 0. /build/src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000000fc33b84 1. /build/src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000000fcc2ea7 2. /build/src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fcc535c 3. /build/src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000000fcc584d 4. /build/src/Common/ThreadPool.h:279: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x00000000169bf193 5. /build/src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x00000000169bf518 6. /build/src/Server/TCPHandler.cpp:1237: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x00000000168f1525 7. /build/src/Server/TCPHandler.cpp:678: DB::TCPHandler::runImpl() @ 0x00000000168e68e5 8. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 9. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 10. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 11. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 12. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 13. ? @ 0x00007fbc6213eac3 14. ? @ 0x00007fbc621d0850 2025.07.28 12:02:18.824118 [ 4963 ] {1f69de53-6b60-46e3-b8ad-522b3c3db400} executeQuery: Code: 394. DB::Exception: Query was cancelled. (QUERY_WAS_CANCELLED) (version 25.3.6.10636.altinitytest (altinity build)) (from [::1]:45126) (comment: 02461_cancel_finish_race.sh) (query 1, line 1) (in query: KILL QUERY WHERE current_database = 'test_dtwle8fg' SYNC FORMAT Null), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000000a074fcb 4. /build/src/Interpreters/ProcessList.cpp:567: DB::QueryStatus::throwQueryWasCancelled() const @ 0x0000000014a4bc85 5. /build/src/Interpreters/ProcessList.cpp:520: DB::QueryStatus::throwProperExceptionIfNeeded(unsigned long const&, unsigned long const&) @ 0x0000000014a4bbd9 6. /build/src/Interpreters/ProcessList.cpp:557: DB::QueryStatus::checkTimeLimit() @ 0x0000000014a4c2cd 7. /build/src/Processors/Executors/PipelineExecutor.cpp:206: DB::PipelineExecutor::finalizeExecution() @ 0x00000000169b13ba 8. /build/src/Processors/Executors/PipelineExecutor.cpp:153: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x00000000169b0584 9. /build/src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:se190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169bfeab 10. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc3d92 11. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fcca080 12. ? @ 0x00007fbc6213eac3 13. ? @ 0x00007fbc621d0850 2025.07.28 12:02:18.875709 [ 17252 ] {13decfaa-9b54-43b8-a132-b20a9bfd996e} executeQuery: Code: 394. DB::Exception: Query was cancelled. (QUERY_WAS_CANCELLED) (version 25.3.6.10636.altinitytest (altinity build)) (from [::1]:45178) (comment: 02461_cancel_finish_race.sh) (query 1, line 1) (in query: KILL QUERY WHERE current_database = 'test_dtwle8fg' SYNC FORMAT Null), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000000a074fcb 4. /build/src/Interpreters/ProcessList.cpp:567: DB::QueryStatus::throwQueryWasCancelled() const @ 0x0000000014a4bc85 5. /build/src/Interpreters/ProcessList.cpp:520: DB::QueryStatus::throwProperExceptionIfNeeded(unsigned long const&, unsigned long const&) @ 0x0000000014a4bbd9 6. /build/src/Interpreters/ProcessList.cpp:557: DB::QueryStatus::checkTimeLimit() @ 0x0000000014a4c2cd 7. /build/src/Processors/Executors/PipelineExecutor.cpp:206: DB::PipelineExecutor::finalizeExecution() @ 0x00000000169b13ba 8. /build/src/Processors/Executors/PipelineExecutor.cpp:153: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x00000000169b0584 9. /build/src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:se190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169bfeab 10. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc3d92 11. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fcca080 12. ? @ 0x00007fbc6213eac3 13. ? @ 0x00007fbc621d0850 2025.07.28 12:02:18.898631 [ 4963 ] {} TCPHandler: Code: 394. DB::Exception: Query was cancelled. (QUERY_WAS_CANCELLED), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000000a074fcb 4. /build/src/Interpreters/ProcessList.cpp:567: DB::QueryStatus::throwQueryWasCancelled() const @ 0x0000000014a4bc85 5. /build/src/Interpreters/ProcessList.cpp:520: DB::QueryStatus::throwProperExceptionIfNeeded(unsigned long const&, unsigned long const&) @ 0x0000000014a4bbd9 6. /build/src/Interpreters/ProcessList.cpp:557: DB::QueryStatus::checkTimeLimit() @ 0x0000000014a4c2cd 7. /build/src/Processors/Executors/PipelineExecutor.cpp:206: DB::PipelineExecutor::finalizeExecution() @ 0x00000000169b13ba 8. /build/src/Processors/Executors/PipelineExecutor.cpp:153: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x00000000169b0584 9. /build/src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:se190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169bfeab 10. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc3d92 11. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fcca080 12. ? @ 0x00007fbc6213eac3 13. ? @ 0x00007fbc621d0850 Job's origin stack trace: 0. /build/src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000000fc33b84 1. /build/src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000000fcc2ea7 2. /build/src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fcc535c 3. /build/src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000000fcc584d 4. /build/src/Common/ThreadPool.h:279: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x00000000169bf193 5. /build/src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x00000000169bf518 6. /build/src/Server/TCPHandler.cpp:1237: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x00000000168f1525 7. /build/src/Server/TCPHandler.cpp:678: DB::TCPHandler::runImpl() @ 0x00000000168e68e5 8. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 9. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 10. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 11. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 12. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 13. ? @ 0x00007fbc6213eac3 14. ? @ 0x00007fbc621d0850 2025.07.28 12:02:18.902071 [ 17252 ] {} TCPHandler: Code: 394. DB::Exception: Query was cancelled. (QUERY_WAS_CANCELLED), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000000a074fcb 4. /build/src/Interpreters/ProcessList.cpp:567: DB::QueryStatus::throwQueryWasCancelled() const @ 0x0000000014a4bc85 5. /build/src/Interpreters/ProcessList.cpp:520: DB::QueryStatus::throwProperExceptionIfNeeded(unsigned long const&, unsigned long const&) @ 0x0000000014a4bbd9 6. /build/src/Interpreters/ProcessList.cpp:557: DB::QueryStatus::checkTimeLimit() @ 0x0000000014a4c2cd 7. /build/src/Processors/Executors/PipelineExecutor.cpp:206: DB::PipelineExecutor::finalizeExecution() @ 0x00000000169b13ba 8. /build/src/Processors/Executors/PipelineExecutor.cpp:153: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x00000000169b0584 9. /build/src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:se190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169bfeab 10. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc3d92 11. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fcca080 12. ? @ 0x00007fbc6213eac3 13. ? @ 0x00007fbc621d0850 Job's origin stack trace: 0. /build/src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000000fc33b84 1. /build/src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000000fcc2ea7 2. /build/src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fcc535c 3. /build/src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000000fcc584d 4. /build/src/Common/ThreadPool.h:279: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x00000000169bf193 5. /build/src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x00000000169bf518 6. /build/src/Server/TCPHandler.cpp:1237: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x00000000168f1525 7. /build/src/Server/TCPHandler.cpp:678: DB::TCPHandler::runImpl() @ 0x00000000168e68e5 8. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 9. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 10. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 11. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 12. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 13. ? @ 0x00007fbc6213eac3 14. ? @ 0x00007fbc621d0850 2025.07.28 12:02:19.038083 [ 62058 ] {f827e2f1-381e-4b3c-89cd-7a3c92376bf1} executeQuery: Code: 394. DB::Exception: Query was cancelled. (QUERY_WAS_CANCELLED) (version 25.3.6.10636.altinitytest (altinity build)) (from [::1]:45246) (comment: 02461_cancel_finish_race.sh) (query 1, line 1) (in query: KILL QUERY WHERE current_database = 'test_dtwle8fg' SYNC FORMAT Null), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000000a074fcb 4. /build/src/Interpreters/ProcessList.cpp:567: DB::QueryStatus::throwQueryWasCancelled() const @ 0x0000000014a4bc85 5. /build/src/Interpreters/ProcessList.cpp:520: DB::QueryStatus::throwProperExceptionIfNeeded(unsigned long const&, unsigned long const&) @ 0x0000000014a4bbd9 6. /build/src/Interpreters/ProcessList.cpp:557: DB::QueryStatus::checkTimeLimit() @ 0x0000000014a4c2cd 7. /build/src/Processors/Executors/PipelineExecutor.cpp:206: DB::PipelineExecutor::finalizeExecution() @ 0x00000000169b13ba 8. /build/src/Processors/Executors/PipelineExecutor.cpp:153: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x00000000169b0584 9. /build/src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:se190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169bfeab 10. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc3d92 11. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fcca080 12. ? @ 0x00007fbc6213eac3 13. ? @ 0x00007fbc621d0850 2025.07.28 12:02:19.051990 [ 62103 ] {b4e3849c-92b9-4e47-b4d5-424d0faf9b6d} executeQuery: Code: 394. DB::Exception: Query was cancelled. (QUERY_WAS_CANCELLED) (version 25.3.6.10636.altinitytest (altinity build)) (from [::1]:45234) (comment: 02461_cancel_finish_race.sh) (query 1, line 1) (in query: KILL QUERY WHERE current_database = 'test_dtwle8fg' SYNC FORMAT Null), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000000a074fcb 4. /build/src/Interpreters/ProcessList.cpp:567: DB::QueryStatus::throwQueryWasCancelled() const @ 0x0000000014a4bc85 5. /build/src/Interpreters/ProcessList.cpp:520: DB::QueryStatus::throwProperExceptionIfNeeded(unsigned long const&, unsigned long const&) @ 0x0000000014a4bbd9 6. /build/src/Interpreters/ProcessList.cpp:557: DB::QueryStatus::checkTimeLimit() @ 0x0000000014a4c2cd 7. /build/src/Processors/Executors/PipelineExecutor.cpp:206: DB::PipelineExecutor::finalizeExecution() @ 0x00000000169b13ba 8. /build/src/Processors/Executors/PipelineExecutor.cpp:153: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x00000000169b0584 9. /build/src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:se190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169bfeab 10. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc3d92 11. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fcca080 12. ? @ 0x00007fbc6213eac3 13. ? @ 0x00007fbc621d0850 2025.07.28 12:02:19.063088 [ 62056 ] {} TCPHandler: Code: 394. DB::Exception: Query was cancelled. (QUERY_WAS_CANCELLED), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000000a074fcb 4. /build/src/Interpreters/ProcessList.cpp:567: DB::QueryStatus::throwQueryWasCancelled() const @ 0x0000000014a4bc85 5. /build/src/Interpreters/ProcessList.cpp:520: DB::QueryStatus::throwProperExceptionIfNeeded(unsigned long const&, unsigned long const&) @ 0x0000000014a4bbd9 6. /build/src/Interpreters/ProcessList.cpp:557: DB::QueryStatus::checkTimeLimit() @ 0x0000000014a4c2cd 7. /build/src/Processors/Executors/PipelineExecutor.cpp:206: DB::PipelineExecutor::finalizeExecution() @ 0x00000000169b13ba 8. /build/src/Processors/Executors/PipelineExecutor.cpp:181: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x00000000169b1726 9. /build/src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x00000000169c081c 10. /build/src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x00000000169c0978 11. /build/src/Interpreters/InterpreterKillQueryQuery.cpp:442: DB::InterpreterKillQueryQuery::getSelectResult(String const&, String const&) @ 0x0000000014cf0f6b 12. /build/src/Interpreters/InterpreterKillQueryQuery.cpp:222: DB::InterpreterKillQueryQuery::execute() @ 0x0000000014cebde2 13. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88dc9 14. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 15. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 16. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 17. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 18. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 19. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 20. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 21. ? @ 0x00007fbc6213eac3 22. ? @ 0x00007fbc621d0850 2025.07.28 12:02:19.097763 [ 62103 ] {} TCPHandler: Code: 394. DB::Exception: Query was cancelled. (QUERY_WAS_CANCELLED), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000000a074fcb 4. /build/src/Interpreters/ProcessList.cpp:567: DB::QueryStatus::throwQueryWasCancelled() const @ 0x0000000014a4bc85 5. /build/src/Interpreters/ProcessList.cpp:520: DB::QueryStatus::throwProperExceptionIfNeeded(unsigned long const&, unsigned long const&) @ 0x0000000014a4bbd9 6. /build/src/Interpreters/ProcessList.cpp:557: DB::QueryStatus::checkTimeLimit() @ 0x0000000014a4c2cd 7. /build/src/Processors/Executors/PipelineExecutor.cpp:206: DB::PipelineExecutor::finalizeExecution() @ 0x00000000169b13ba 8. /build/src/Processors/Executors/PipelineExecutor.cpp:153: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x00000000169b0584 9. /build/src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:se190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169bfeab 10. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc3d92 11. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fcca080 12. ? @ 0x00007fbc6213eac3 13. ? @ 0x00007fbc621d0850 Job's origin stack trace: 0. /build/src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000000fc33b84 1. /build/src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000000fcc2ea7 2. /build/src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fcc535c 3. /build/src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000000fcc584d 4. /build/src/Common/ThreadPool.h:279: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x00000000169bf193 5. /build/src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x00000000169bf518 6. /build/src/Server/TCPHandler.cpp:1237: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x00000000168f1525 7. /build/src/Server/TCPHandler.cpp:678: DB::TCPHandler::runImpl() @ 0x00000000168e68e5 8. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 9. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 10. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 11. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 12. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 13. ? @ 0x00007fbc6213eac3 14. ? @ 0x00007fbc621d0850 2025.07.28 12:02:19.122104 [ 62058 ] {} TCPHandler: Code: 394. DB::Exception: Query was cancelled. (QUERY_WAS_CANCELLED), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000000a074fcb 4. /build/src/Interpreters/ProcessList.cpp:567: DB::QueryStatus::throwQueryWasCancelled() const @ 0x0000000014a4bc85 5. /build/src/Interpreters/ProcessList.cpp:520: DB::QueryStatus::throwProperExceptionIfNeeded(unsigned long const&, unsigned long const&) @ 0x0000000014a4bbd9 6. /build/src/Interpreters/ProcessList.cpp:557: DB::QueryStatus::checkTimeLimit() @ 0x0000000014a4c2cd 7. /build/src/Processors/Executors/PipelineExecutor.cpp:206: DB::PipelineExecutor::finalizeExecution() @ 0x00000000169b13ba 8. /build/src/Processors/Executors/PipelineExecutor.cpp:153: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x00000000169b0584 9. /build/src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:se190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169bfeab 10. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc3d92 11. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fcca080 12. ? @ 0x00007fbc6213eac3 13. ? @ 0x00007fbc621d0850 Job's origin stack trace: 0. /build/src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000000fc33b84 1. /build/src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000000fcc2ea7 2. /build/src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fcc535c 3. /build/src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000000fcc584d 4. /build/src/Common/ThreadPool.h:279: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x00000000169bf193 5. /build/src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x00000000169bf518 6. /build/src/Server/TCPHandler.cpp:1237: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x00000000168f1525 7. /build/src/Server/TCPHandler.cpp:678: DB::TCPHandler::runImpl() @ 0x00000000168e68e5 8. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 9. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 10. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 11. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 12. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 13. ? @ 0x00007fbc6213eac3 14. ? @ 0x00007fbc621d0850 2025.07.28 12:02:19.347196 [ 17255 ] {c4b52ceb-d812-4a52-af47-1964cbab8148} executeQuery: Code: 394. DB::Exception: Query was cancelled. (QUERY_WAS_CANCELLED) (version 25.3.6.10636.altinitytest (altinity build)) (from [::1]:45304) (comment: 02461_cancel_finish_race.sh) (query 1, line 1) (in query: KILL QUERY WHERE current_database = 'test_dtwle8fg' SYNC FORMAT Null), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000000a074fcb 4. /build/src/Interpreters/ProcessList.cpp:567: DB::QueryStatus::throwQueryWasCancelled() const @ 0x0000000014a4bc85 5. /build/src/Interpreters/ProcessList.cpp:520: DB::QueryStatus::throwProperExceptionIfNeeded(unsigned long const&, unsigned long const&) @ 0x0000000014a4bbd9 6. /build/src/Interpreters/ProcessList.cpp:531: DB::QueryStatus::addPipelineExecutor(DB::PipelineExecutor*) @ 0x0000000014a4bd9c 7. /build/src/Processors/Executors/PipelineExecutor.cpp:73: DB::PipelineExecutor::PipelineExecutor(std::shared_ptr, std::allocator>>>&, std::shared_ptr) @ 0x00000000169afe31 8. /build/contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x00000000169bef66 9. /build/src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x00000000169bf518 10. /build/src/Server/TCPHandler.cpp:1237: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x00000000168f1525 11. /build/src/Server/TCPHandler.cpp:678: DB::TCPHandler::runImpl() @ 0x00000000168e68e5 12. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 13. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 14. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 16. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 17. ? @ 0x00007fbc6213eac3 18. ? @ 0x00007fbc621d0850 2025.07.28 12:02:19.384053 [ 17255 ] {} TCPHandler: Code: 394. DB::Exception: Query was cancelled. (QUERY_WAS_CANCELLED), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000000a074fcb 4. /build/src/Interpreters/ProcessList.cpp:567: DB::QueryStatus::throwQueryWasCancelled() const @ 0x0000000014a4bc85 5. /build/src/Interpreters/ProcessList.cpp:520: DB::QueryStatus::throwProperExceptionIfNeeded(unsigned long const&, unsigned long const&) @ 0x0000000014a4bbd9 6. /build/src/Interpreters/ProcessList.cpp:531: DB::QueryStatus::addPipelineExecutor(DB::PipelineExecutor*) @ 0x0000000014a4bd9c 7. /build/src/Processors/Executors/PipelineExecutor.cpp:73: DB::PipelineExecutor::PipelineExecutor(std::shared_ptr, std::allocator>>>&, std::shared_ptr) @ 0x00000000169afe31 8. /build/contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x00000000169bef66 9. /build/src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x00000000169bf518 10. /build/src/Server/TCPHandler.cpp:1237: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x00000000168f1525 11. /build/src/Server/TCPHandler.cpp:678: DB::TCPHandler::runImpl() @ 0x00000000168e68e5 12. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 13. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 14. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 16. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 17. ? @ 0x00007fbc6213eac3 18. ? @ 0x00007fbc621d0850 2025.07.28 12:02:19.432491 [ 17252 ] {} TCPHandler: Code: 394. DB::Exception: Query was cancelled. (QUERY_WAS_CANCELLED), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000000a074fcb 4. /build/src/Interpreters/ProcessList.cpp:567: DB::QueryStatus::throwQueryWasCancelled() const @ 0x0000000014a4bc85 5. /build/src/Interpreters/ProcessList.cpp:520: DB::QueryStatus::throwProperExceptionIfNeeded(unsigned long const&, unsigned long const&) @ 0x0000000014a4bbd9 6. /build/src/Interpreters/ProcessList.cpp:557: DB::QueryStatus::checkTimeLimit() @ 0x0000000014a4c2cd 7. /build/src/Processors/Executors/PipelineExecutor.cpp:206: DB::PipelineExecutor::finalizeExecution() @ 0x00000000169b13ba 8. /build/src/Processors/Executors/PipelineExecutor.cpp:181: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x00000000169b1726 9. /build/src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x00000000169c081c 10. /build/src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x00000000169c0978 11. /build/src/Interpreters/InterpreterKillQueryQuery.cpp:439: DB::InterpreterKillQueryQuery::getSelectResult(String const&, String const&) @ 0x0000000014cf0f04 12. /build/src/Interpreters/InterpreterKillQueryQuery.cpp:222: DB::InterpreterKillQueryQuery::execute() @ 0x0000000014cebde2 13. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88dc9 14. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 15. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 16. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 17. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 18. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 19. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 20. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 21. ? @ 0x00007fbc6213eac3 22. ? @ 0x00007fbc621d0850 2025.07.28 12:02:19.472587 [ 62093 ] {73cf759e-56c2-4627-8128-7f2916065809} executeQuery: Code: 394. DB::Exception: Query was cancelled. (QUERY_WAS_CANCELLED) (version 25.3.6.10636.altinitytest (altinity build)) (from [::1]:45274) (comment: 02461_cancel_finish_race.sh) (query 1, line 1) (in query: KILL QUERY WHERE current_database = 'test_dtwle8fg' SYNC FORMAT Null), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000000a074fcb 4. /build/src/Interpreters/ProcessList.cpp:567: DB::QueryStatus::throwQueryWasCancelled() const @ 0x0000000014a4bc85 5. /build/src/Interpreters/ProcessList.cpp:520: DB::QueryStatus::throwProperExceptionIfNeeded(unsigned long const&, unsigned long const&) @ 0x0000000014a4bbd9 6. /build/src/Interpreters/ProcessList.cpp:557: DB::QueryStatus::checkTimeLimit() @ 0x0000000014a4c2cd 7. /build/src/Processors/Executors/PipelineExecutor.cpp:206: DB::PipelineExecutor::finalizeExecution() @ 0x00000000169b13ba 8. /build/src/Processors/Executors/PipelineExecutor.cpp:153: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x00000000169b0584 9. /build/src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:se190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169bfeab 10. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc3d92 11. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fcca080 12. ? @ 0x00007fbc6213eac3 13. ? @ 0x00007fbc621d0850 2025.07.28 12:02:19.473929 [ 63425 ] {} TCPHandler: Code: 394. DB::Exception: Query was cancelled. (QUERY_WAS_CANCELLED), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000000a074fcb 4. /build/src/Interpreters/ProcessList.cpp:567: DB::QueryStatus::throwQueryWasCancelled() const @ 0x0000000014a4bc85 5. /build/src/Interpreters/ProcessList.cpp:520: DB::QueryStatus::throwProperExceptionIfNeeded(unsigned long const&, unsigned long const&) @ 0x0000000014a4bbd9 6. /build/src/Interpreters/ProcessList.cpp:557: DB::QueryStatus::checkTimeLimit() @ 0x0000000014a4c2cd 7. /build/src/Processors/Executors/PipelineExecutor.cpp:206: DB::PipelineExecutor::finalizeExecution() @ 0x00000000169b13ba 8. /build/src/Processors/Executors/PipelineExecutor.cpp:181: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x00000000169b1726 9. /build/src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x00000000169c081c 10. /build/src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x00000000169c0978 11. /build/src/Interpreters/InterpreterKillQueryQuery.cpp:439: DB::InterpreterKillQueryQuery::getSelectResult(String const&, String const&) @ 0x0000000014cf0f04 12. /build/src/Interpreters/InterpreterKillQueryQuery.cpp:222: DB::InterpreterKillQueryQuery::execute() @ 0x0000000014cebde2 13. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88dc9 14. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 15. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 16. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 17. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 18. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 19. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 20. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 21. ? @ 0x00007fbc6213eac3 22. ? @ 0x00007fbc621d0850 2025.07.28 12:02:19.486425 [ 62314 ] {} TCPHandler: Code: 394. DB::Exception: Query was cancelled. (QUERY_WAS_CANCELLED), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000000a074fcb 4. /build/src/Interpreters/ProcessList.cpp:567: DB::QueryStatus::throwQueryWasCancelled() const @ 0x0000000014a4bc85 5. /build/src/Interpreters/ProcessList.cpp:520: DB::QueryStatus::throwProperExceptionIfNeeded(unsigned long const&, unsigned long const&) @ 0x0000000014a4bbd9 6. /build/src/Interpreters/ProcessList.cpp:531: DB::QueryStatus::addPipelineExecutor(DB::PipelineExecutor*) @ 0x0000000014a4bd9c 7. /build/src/Processors/Executors/PipelineExecutor.cpp:73: DB::PipelineExecutor::PipelineExecutor(std::shared_ptr, std::allocator>>>&, std::shared_ptr) @ 0x00000000169afe31 8. /build/contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x00000000169c07b5 9. /build/src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x00000000169c0978 10. /build/src/Interpreters/InterpreterKillQueryQuery.cpp:439: DB::InterpreterKillQueryQuery::getSelectResult(String const&, String const&) @ 0x0000000014cf0f04 11. /build/src/Interpreters/InterpreterKillQueryQuery.cpp:222: DB::InterpreterKillQueryQuery::execute() @ 0x0000000014cebde2 12. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88dc9 13. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 14. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 15. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 16. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 17. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 18. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 19. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 20. ? @ 0x00007fbc6213eac3 21. ? @ 0x00007fbc621d0850 2025.07.28 12:02:19.500815 [ 62093 ] {} TCPHandler: Code: 394. DB::Exception: Query was cancelled. (QUERY_WAS_CANCELLED), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000000a074fcb 4. /build/src/Interpreters/ProcessList.cpp:567: DB::QueryStatus::throwQueryWasCancelled() const @ 0x0000000014a4bc85 5. /build/src/Interpreters/ProcessList.cpp:520: DB::QueryStatus::throwProperExceptionIfNeeded(unsigned long const&, unsigned long const&) @ 0x0000000014a4bbd9 6. /build/src/Interpreters/ProcessList.cpp:557: DB::QueryStatus::checkTimeLimit() @ 0x0000000014a4c2cd 7. /build/src/Processors/Executors/PipelineExecutor.cpp:206: DB::PipelineExecutor::finalizeExecution() @ 0x00000000169b13ba 8. /build/src/Processors/Executors/PipelineExecutor.cpp:153: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x00000000169b0584 9. /build/src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:se190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169bfeab 10. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc3d92 11. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fcca080 12. ? @ 0x00007fbc6213eac3 13. ? @ 0x00007fbc621d0850 Job's origin stack trace: 0. /build/src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000000fc33b84 1. /build/src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000000fcc2ea7 2. /build/src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fcc535c 3. /build/src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000000fcc584d 4. /build/src/Common/ThreadPool.h:279: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x00000000169bf193 5. /build/src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x00000000169bf518 6. /build/src/Server/TCPHandler.cpp:1237: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x00000000168f1525 7. /build/src/Server/TCPHandler.cpp:678: DB::TCPHandler::runImpl() @ 0x00000000168e68e5 8. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 9. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 10. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 11. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 12. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 13. ? @ 0x00007fbc6213eac3 14. ? @ 0x00007fbc621d0850 2025.07.28 12:02:19.540424 [ 62325 ] {c29f81f1-e277-469c-8d3c-5153adff200e} executeQuery: Code: 394. DB::Exception: Query was cancelled. (QUERY_WAS_CANCELLED) (version 25.3.6.10636.altinitytest (altinity build)) (from [::1]:45314) (comment: 02461_cancel_finish_race.sh) (query 1, line 1) (in query: KILL QUERY WHERE current_database = 'test_dtwle8fg' SYNC FORMAT Null), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000000a074fcb 4. /build/src/Interpreters/ProcessList.cpp:567: DB::QueryStatus::throwQueryWasCancelled() const @ 0x0000000014a4bc85 5. /build/src/Interpreters/ProcessList.cpp:520: DB::QueryStatus::throwProperExceptionIfNeeded(unsigned long const&, unsigned long const&) @ 0x0000000014a4bbd9 6. /build/src/Interpreters/ProcessList.cpp:557: DB::QueryStatus::checkTimeLimit() @ 0x0000000014a4c2cd 7. /build/src/Processors/Executors/PipelineExecutor.cpp:206: DB::PipelineExecutor::finalizeExecution() @ 0x00000000169b13ba 8. /build/src/Processors/Executors/PipelineExecutor.cpp:153: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x00000000169b0584 9. /build/src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:se190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169bfeab 10. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc3d92 11. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fcca080 12. ? @ 0x00007fbc6213eac3 13. ? @ 0x00007fbc621d0850 2025.07.28 12:02:19.547065 [ 62325 ] {} TCPHandler: Code: 394. DB::Exception: Query was cancelled. (QUERY_WAS_CANCELLED), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000000a074fcb 4. /build/src/Interpreters/ProcessList.cpp:567: DB::QueryStatus::throwQueryWasCancelled() const @ 0x0000000014a4bc85 5. /build/src/Interpreters/ProcessList.cpp:520: DB::QueryStatus::throwProperExceptionIfNeeded(unsigned long const&, unsigned long const&) @ 0x0000000014a4bbd9 6. /build/src/Interpreters/ProcessList.cpp:557: DB::QueryStatus::checkTimeLimit() @ 0x0000000014a4c2cd 7. /build/src/Processors/Executors/PipelineExecutor.cpp:206: DB::PipelineExecutor::finalizeExecution() @ 0x00000000169b13ba 8. /build/src/Processors/Executors/PipelineExecutor.cpp:153: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x00000000169b0584 9. /build/src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:se190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169bfeab 10. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc3d92 11. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fcca080 12. ? @ 0x00007fbc6213eac3 13. ? @ 0x00007fbc621d0850 Job's origin stack trace: 0. /build/src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000000fc33b84 1. /build/src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000000fcc2ea7 2. /build/src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fcc535c 3. /build/src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000000fcc584d 4. /build/src/Common/ThreadPool.h:279: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x00000000169bf193 5. /build/src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x00000000169bf518 6. /build/src/Server/TCPHandler.cpp:1237: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x00000000168f1525 7. /build/src/Server/TCPHandler.cpp:678: DB::TCPHandler::runImpl() @ 0x00000000168e68e5 8. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 9. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 10. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 11. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 12. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 13. ? @ 0x00007fbc6213eac3 14. ? @ 0x00007fbc621d0850 2025.07.28 12:02:19.571092 [ 3972 ] {} test_13.rmt2 (7f9b740d-015c-470e-8cc6-8ba33be0dc63): auto DB::StorageReplicatedMergeTree::processQueueEntry(ReplicatedMergeTreeQueue::SelectedEntryPtr)::(anonymous class)::operator()(LogEntryPtr &) const: Code: 86. DB::HTTPException: Received error from remote server http://146b4357c08d:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Ftest%2F01165%2Ftest_13%2Frmt%2Freplicas%2F1&part=20250728_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.6.10636.altinitytest (altinity build)) '. (RECEIVED_ERROR_FROM_REMOTE_IO_SERVER), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.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 const&, int&&, String const&, unsigned long&&, String const&) @ 0x000000000feda8d9 4. /build/src/IO/HTTPCommon.cpp:104: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x000000000feda6e2 5. /build/src/IO/HTTPCommon.cpp:93: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x000000000feda537 6. /build/src/IO/ReadWriteBufferFromHTTP.cpp:277: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x000000001184a4c4 7. /build/src/IO/ReadWriteBufferFromHTTP.cpp:285: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x000000001184a615 8. /build/src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x000000001184ae59 9. /build/src/IO/ReadWriteBufferFromHTTP.cpp:472: void std::__function::__policy_invoker::__call_impl[abi:se190107]>(std::__function::__policy_storage const*) @ 0x000000001184cedd 10. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001184858b 11. /build/src/IO/ReadWriteBufferFromHTTP.cpp:465: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x000000001184bf0b 12. /build/src/IO/ReadBuffer.h:60: DB::ReadBuffer::next() @ 0x000000000a148c7b 13. /build/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) @ 0x0000000011849fb2 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]>&)>&, 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&) @ 0x0000000011841980 15. /build/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) @ 0x000000001621208e 16. /build/src/Storages/StorageReplicatedMergeTree.cpp:5228: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl[abi:se190107] const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000015f9a5fe 17. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000015ed8bfd 18. /build/src/Storages/StorageReplicatedMergeTree.cpp:2514: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x0000000015ec9aab 19. /build/src/Storages/StorageReplicatedMergeTree.cpp:2349: DB::StorageReplicatedMergeTree::executeLogEntry(DB::ReplicatedMergeTreeLogEntry&) @ 0x0000000015eba91b 20. /build/src/Storages/StorageReplicatedMergeTree.cpp:3876: bool std::__function::__policy_invoker&)>::__call_impl[abi:se190107])::$_1, bool (std::shared_ptr&)>>(std::__function::__policy_storage const*, std::shared_ptr&) @ 0x0000000015f9837e 21. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000165d6fc3 22. /build/src/Storages/StorageReplicatedMergeTree.cpp:3872: DB::StorageReplicatedMergeTree::processQueueEntry(std::shared_ptr) @ 0x0000000015efc18a 23. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001624c1b2 24. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000162f9c70 25. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x00000000162fa55a 26. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc6653 27. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000000fccc4c3 28. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc3d92 29. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fcca080 30. ? @ 0x00007fbc6213eac3 31. ? @ 0x00007fbc621d0850 (version 25.3.6.10636.altinitytest (altinity build)) 2025.07.28 12:02:19.601622 [ 62056 ] {dce9bb11-887d-47ce-8e03-6a944659fb51} executeQuery: Code: 394. DB::Exception: Query was cancelled. (QUERY_WAS_CANCELLED) (version 25.3.6.10636.altinitytest (altinity build)) (from [::1]:45410) (comment: 02461_cancel_finish_race.sh) (query 1, line 1) (in query: KILL QUERY WHERE current_database = 'test_dtwle8fg' SYNC FORMAT Null), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000000a074fcb 4. /build/src/Interpreters/ProcessList.cpp:567: DB::QueryStatus::throwQueryWasCancelled() const @ 0x0000000014a4bc85 5. /build/src/Interpreters/ProcessList.cpp:520: DB::QueryStatus::throwProperExceptionIfNeeded(unsigned long const&, unsigned long const&) @ 0x0000000014a4bbd9 6. /build/src/Interpreters/ProcessList.cpp:557: DB::QueryStatus::checkTimeLimit() @ 0x0000000014a4c2cd 7. /build/src/Processors/Executors/PipelineExecutor.cpp:206: DB::PipelineExecutor::finalizeExecution() @ 0x00000000169b13ba 8. /build/src/Processors/Executors/PipelineExecutor.cpp:153: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x00000000169b0584 9. /build/src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:se190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169bfeab 10. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc3d92 11. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fcca080 12. ? @ 0x00007fbc6213eac3 13. ? @ 0x00007fbc621d0850 2025.07.28 12:02:19.621799 [ 62056 ] {} TCPHandler: Code: 394. DB::Exception: Query was cancelled. (QUERY_WAS_CANCELLED), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000000a074fcb 4. /build/src/Interpreters/ProcessList.cpp:567: DB::QueryStatus::throwQueryWasCancelled() const @ 0x0000000014a4bc85 5. /build/src/Interpreters/ProcessList.cpp:520: DB::QueryStatus::throwProperExceptionIfNeeded(unsigned long const&, unsigned long const&) @ 0x0000000014a4bbd9 6. /build/src/Interpreters/ProcessList.cpp:557: DB::QueryStatus::checkTimeLimit() @ 0x0000000014a4c2cd 7. /build/src/Processors/Executors/PipelineExecutor.cpp:206: DB::PipelineExecutor::finalizeExecution() @ 0x00000000169b13ba 8. /build/src/Processors/Executors/PipelineExecutor.cpp:153: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x00000000169b0584 9. /build/src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:se190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169bfeab 10. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc3d92 11. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fcca080 12. ? @ 0x00007fbc6213eac3 13. ? @ 0x00007fbc621d0850 Job's origin stack trace: 0. /build/src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000000fc33b84 1. /build/src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000000fcc2ea7 2. /build/src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fcc535c 3. /build/src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000000fcc584d 4. /build/src/Common/ThreadPool.h:279: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x00000000169bf193 5. /build/src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x00000000169bf518 6. /build/src/Server/TCPHandler.cpp:1237: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x00000000168f1525 7. /build/src/Server/TCPHandler.cpp:678: DB::TCPHandler::runImpl() @ 0x00000000168e68e5 8. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 9. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 10. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 11. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 12. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 13. ? @ 0x00007fbc6213eac3 14. ? @ 0x00007fbc621d0850 2025.07.28 12:02:19.687434 [ 7625 ] {ca93c3dd-cba9-438a-b1e7-1141c4c73928} executeQuery: Code: 394. DB::Exception: Query was cancelled. (QUERY_WAS_CANCELLED) (version 25.3.6.10636.altinitytest (altinity build)) (from [::1]:45374) (comment: 02461_cancel_finish_race.sh) (query 1, line 1) (in query: KILL QUERY WHERE current_database = 'test_dtwle8fg' SYNC FORMAT Null), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000000a074fcb 4. /build/src/Interpreters/ProcessList.cpp:567: DB::QueryStatus::throwQueryWasCancelled() const @ 0x0000000014a4bc85 5. /build/src/Interpreters/ProcessList.cpp:520: DB::QueryStatus::throwProperExceptionIfNeeded(unsigned long const&, unsigned long const&) @ 0x0000000014a4bbd9 6. /build/src/Interpreters/ProcessList.cpp:557: DB::QueryStatus::checkTimeLimit() @ 0x0000000014a4c2cd 7. /build/src/Processors/Executors/PipelineExecutor.cpp:206: DB::PipelineExecutor::finalizeExecution() @ 0x00000000169b13ba 8. /build/src/Processors/Executors/PipelineExecutor.cpp:153: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x00000000169b0584 9. /build/src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:se190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169bfeab 10. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc3d92 11. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fcca080 12. ? @ 0x00007fbc6213eac3 13. ? @ 0x00007fbc621d0850 2025.07.28 12:02:19.700796 [ 7625 ] {} TCPHandler: Code: 394. DB::Exception: Query was cancelled. (QUERY_WAS_CANCELLED), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000000a074fcb 4. /build/src/Interpreters/ProcessList.cpp:567: DB::QueryStatus::throwQueryWasCancelled() const @ 0x0000000014a4bc85 5. /build/src/Interpreters/ProcessList.cpp:520: DB::QueryStatus::throwProperExceptionIfNeeded(unsigned long const&, unsigned long const&) @ 0x0000000014a4bbd9 6. /build/src/Interpreters/ProcessList.cpp:557: DB::QueryStatus::checkTimeLimit() @ 0x0000000014a4c2cd 7. /build/src/Processors/Executors/PipelineExecutor.cpp:206: DB::PipelineExecutor::finalizeExecution() @ 0x00000000169b13ba 8. /build/src/Processors/Executors/PipelineExecutor.cpp:153: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x00000000169b0584 9. /build/src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:se190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169bfeab 10. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc3d92 11. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fcca080 12. ? @ 0x00007fbc6213eac3 13. ? @ 0x00007fbc621d0850 Job's origin stack trace: 0. /build/src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000000fc33b84 1. /build/src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000000fcc2ea7 2. /build/src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fcc535c 3. /build/src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000000fcc584d 4. /build/src/Common/ThreadPool.h:279: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x00000000169bf193 5. /build/src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x00000000169bf518 6. /build/src/Server/TCPHandler.cpp:1237: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x00000000168f1525 7. /build/src/Server/TCPHandler.cpp:678: DB::TCPHandler::runImpl() @ 0x00000000168e68e5 8. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 9. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 10. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 11. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 12. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 13. ? @ 0x00007fbc6213eac3 14. ? @ 0x00007fbc621d0850 2025.07.28 12:02:19.750313 [ 4963 ] {} TCPHandler: Code: 394. DB::Exception: Query 'e7c4cf22-b58d-4d78-af5a-f5fc4ed72b4a' is killed in pending state. (QUERY_WAS_CANCELLED), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x000000000a06b56b 4. /build/src/Interpreters/executeQuery.cpp:1522: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c8a4ef 5. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 6. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 7. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 8. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 9. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 10. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 11. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 12. ? @ 0x00007fbc6213eac3 13. ? @ 0x00007fbc621d0850 2025.07.28 12:02:19.849387 [ 3968 ] {} test_13.rmt2 (7f9b740d-015c-470e-8cc6-8ba33be0dc63): auto DB::StorageReplicatedMergeTree::processQueueEntry(ReplicatedMergeTreeQueue::SelectedEntryPtr)::(anonymous class)::operator()(LogEntryPtr &) const: Code: 86. DB::HTTPException: Received error from remote server http://146b4357c08d:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Ftest%2F01165%2Ftest_13%2Frmt%2Freplicas%2F1&part=20250728_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.6.10636.altinitytest (altinity build)) '. (RECEIVED_ERROR_FROM_REMOTE_IO_SERVER), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.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 const&, int&&, String const&, unsigned long&&, String const&) @ 0x000000000feda8d9 4. /build/src/IO/HTTPCommon.cpp:104: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x000000000feda6e2 5. /build/src/IO/HTTPCommon.cpp:93: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x000000000feda537 6. /build/src/IO/ReadWriteBufferFromHTTP.cpp:277: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x000000001184a4c4 7. /build/src/IO/ReadWriteBufferFromHTTP.cpp:285: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x000000001184a615 8. /build/src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x000000001184ae59 9. /build/src/IO/ReadWriteBufferFromHTTP.cpp:472: void std::__function::__policy_invoker::__call_impl[abi:se190107]>(std::__function::__policy_storage const*) @ 0x000000001184cedd 10. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001184858b 11. /build/src/IO/ReadWriteBufferFromHTTP.cpp:465: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x000000001184bf0b 12. /build/src/IO/ReadBuffer.h:60: DB::ReadBuffer::next() @ 0x000000000a148c7b 13. /build/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) @ 0x0000000011849fb2 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]>&)>&, 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&) @ 0x0000000011841980 15. /build/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) @ 0x000000001621208e 16. /build/src/Storages/StorageReplicatedMergeTree.cpp:5228: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl[abi:se190107] const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000015f9a5fe 17. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000015ed8bfd 18. /build/src/Storages/StorageReplicatedMergeTree.cpp:2514: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x0000000015ec9aab 19. /build/src/Storages/StorageReplicatedMergeTree.cpp:2349: DB::StorageReplicatedMergeTree::executeLogEntry(DB::ReplicatedMergeTreeLogEntry&) @ 0x0000000015eba91b 20. /build/src/Storages/StorageReplicatedMergeTree.cpp:3876: bool std::__function::__policy_invoker&)>::__call_impl[abi:se190107])::$_1, bool (std::shared_ptr&)>>(std::__function::__policy_storage const*, std::shared_ptr&) @ 0x0000000015f9837e 21. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000165d6fc3 22. /build/src/Storages/StorageReplicatedMergeTree.cpp:3872: DB::StorageReplicatedMergeTree::processQueueEntry(std::shared_ptr) @ 0x0000000015efc18a 23. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001624c1b2 24. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000162f9c70 25. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x00000000162fa55a 26. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc6653 27. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000000fccc4c3 28. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc3d92 29. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fcca080 30. ? @ 0x00007fbc6213eac3 31. ? @ 0x00007fbc621d0850 (version 25.3.6.10636.altinitytest (altinity build)) 2025.07.28 12:02:19.877346 [ 62093 ] {243fa8a1-7c53-4b3f-bdf0-05a07de21954} executeQuery: Code: 394. DB::Exception: Query was cancelled. (QUERY_WAS_CANCELLED) (version 25.3.6.10636.altinitytest (altinity build)) (from [::1]:45558) (comment: 02461_cancel_finish_race.sh) (query 1, line 1) (in query: KILL QUERY WHERE current_database = 'test_dtwle8fg' SYNC FORMAT Null), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000000a074fcb 4. /build/src/Interpreters/ProcessList.cpp:567: DB::QueryStatus::throwQueryWasCancelled() const @ 0x0000000014a4bc85 5. /build/src/Interpreters/ProcessList.cpp:520: DB::QueryStatus::throwProperExceptionIfNeeded(unsigned long const&, unsigned long const&) @ 0x0000000014a4bbd9 6. /build/src/Interpreters/ProcessList.cpp:557: DB::QueryStatus::checkTimeLimit() @ 0x0000000014a4c2cd 7. /build/src/Processors/Executors/PipelineExecutor.cpp:206: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x00000000169b03a3 8. /build/src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:se190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169bfeab 9. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc3d92 10. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fcca080 11. ? @ 0x00007fbc6213eac3 12. ? @ 0x00007fbc621d0850 2025.07.28 12:02:19.899648 [ 17371 ] {} TCPHandler: Code: 394. DB::Exception: Query was cancelled. (QUERY_WAS_CANCELLED), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000000a074fcb 4. /build/src/Interpreters/ProcessList.cpp:567: DB::QueryStatus::throwQueryWasCancelled() const @ 0x0000000014a4bc85 5. /build/src/Interpreters/ProcessList.cpp:520: DB::QueryStatus::throwProperExceptionIfNeeded(unsigned long const&, unsigned long const&) @ 0x0000000014a4bbd9 6. /build/src/Interpreters/ProcessList.cpp:531: DB::QueryStatus::addPipelineExecutor(DB::PipelineExecutor*) @ 0x0000000014a4bd9c 7. /build/src/Processors/Executors/PipelineExecutor.cpp:73: DB::PipelineExecutor::PipelineExecutor(std::shared_ptr, std::allocator>>>&, std::shared_ptr) @ 0x00000000169afe31 8. /build/contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x00000000169c07b5 9. /build/src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x00000000169c0978 10. /build/src/Interpreters/InterpreterKillQueryQuery.cpp:439: DB::InterpreterKillQueryQuery::getSelectResult(String const&, String const&) @ 0x0000000014cf0f04 11. /build/src/Interpreters/InterpreterKillQueryQuery.cpp:222: DB::InterpreterKillQueryQuery::execute() @ 0x0000000014cebde2 12. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88dc9 13. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 14. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 15. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 16. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 17. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 18. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 19. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 20. ? @ 0x00007fbc6213eac3 21. ? @ 0x00007fbc621d0850 2025.07.28 12:02:19.925618 [ 62093 ] {} TCPHandler: Code: 394. DB::Exception: Query was cancelled. (QUERY_WAS_CANCELLED), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000000a074fcb 4. /build/src/Interpreters/ProcessList.cpp:567: DB::QueryStatus::throwQueryWasCancelled() const @ 0x0000000014a4bc85 5. /build/src/Interpreters/ProcessList.cpp:520: DB::QueryStatus::throwProperExceptionIfNeeded(unsigned long const&, unsigned long const&) @ 0x0000000014a4bbd9 6. /build/src/Interpreters/ProcessList.cpp:557: DB::QueryStatus::checkTimeLimit() @ 0x0000000014a4c2cd 7. /build/src/Processors/Executors/PipelineExecutor.cpp:206: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x00000000169b03a3 8. /build/src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:se190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169bfeab 9. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc3d92 10. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fcca080 11. ? @ 0x00007fbc6213eac3 12. ? @ 0x00007fbc621d0850 Job's origin stack trace: 0. /build/src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000000fc33b84 1. /build/src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000000fcc2ea7 2. /build/src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fcc535c 3. /build/src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000000fcc584d 4. /build/src/Common/ThreadPool.h:279: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x00000000169bf193 5. /build/src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x00000000169bf518 6. /build/src/Server/TCPHandler.cpp:1237: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x00000000168f1525 7. /build/src/Server/TCPHandler.cpp:678: DB::TCPHandler::runImpl() @ 0x00000000168e68e5 8. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 9. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 10. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 11. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 12. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 13. ? @ 0x00007fbc6213eac3 14. ? @ 0x00007fbc621d0850 2025.07.28 12:02:19.943393 [ 62057 ] {} TCPHandler: Code: 394. DB::Exception: Query 'd21e7948-d047-462c-a0d3-eafa71498b6e' is killed in pending state. (QUERY_WAS_CANCELLED), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x000000000a06b56b 4. /build/src/Interpreters/executeQuery.cpp:1522: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c8a4ef 5. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 6. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 7. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 8. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 9. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 10. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 11. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 12. ? @ 0x00007fbc6213eac3 13. ? @ 0x00007fbc621d0850 2025.07.28 12:02:20.158884 [ 3962 ] {} test_13.rmt2 (7f9b740d-015c-470e-8cc6-8ba33be0dc63): auto DB::StorageReplicatedMergeTree::processQueueEntry(ReplicatedMergeTreeQueue::SelectedEntryPtr)::(anonymous class)::operator()(LogEntryPtr &) const: Code: 86. DB::HTTPException: Received error from remote server http://146b4357c08d:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Ftest%2F01165%2Ftest_13%2Frmt%2Freplicas%2F1&part=20250728_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.6.10636.altinitytest (altinity build)) '. (RECEIVED_ERROR_FROM_REMOTE_IO_SERVER), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.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 const&, int&&, String const&, unsigned long&&, String const&) @ 0x000000000feda8d9 4. /build/src/IO/HTTPCommon.cpp:104: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x000000000feda6e2 5. /build/src/IO/HTTPCommon.cpp:93: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x000000000feda537 6. /build/src/IO/ReadWriteBufferFromHTTP.cpp:277: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x000000001184a4c4 7. /build/src/IO/ReadWriteBufferFromHTTP.cpp:285: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x000000001184a615 8. /build/src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x000000001184ae59 9. /build/src/IO/ReadWriteBufferFromHTTP.cpp:472: void std::__function::__policy_invoker::__call_impl[abi:se190107]>(std::__function::__policy_storage const*) @ 0x000000001184cedd 10. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001184858b 11. /build/src/IO/ReadWriteBufferFromHTTP.cpp:465: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x000000001184bf0b 12. /build/src/IO/ReadBuffer.h:60: DB::ReadBuffer::next() @ 0x000000000a148c7b 13. /build/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) @ 0x0000000011849fb2 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]>&)>&, 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&) @ 0x0000000011841980 15. /build/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) @ 0x000000001621208e 16. /build/src/Storages/StorageReplicatedMergeTree.cpp:5228: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl[abi:se190107] const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000015f9a5fe 17. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000015ed8bfd 18. /build/src/Storages/StorageReplicatedMergeTree.cpp:2514: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x0000000015ec9aab 19. /build/src/Storages/StorageReplicatedMergeTree.cpp:2349: DB::StorageReplicatedMergeTree::executeLogEntry(DB::ReplicatedMergeTreeLogEntry&) @ 0x0000000015eba91b 20. /build/src/Storages/StorageReplicatedMergeTree.cpp:3876: bool std::__function::__policy_invoker&)>::__call_impl[abi:se190107])::$_1, bool (std::shared_ptr&)>>(std::__function::__policy_storage const*, std::shared_ptr&) @ 0x0000000015f9837e 21. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000165d6fc3 22. /build/src/Storages/StorageReplicatedMergeTree.cpp:3872: DB::StorageReplicatedMergeTree::processQueueEntry(std::shared_ptr) @ 0x0000000015efc18a 23. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001624c1b2 24. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000162f9c70 25. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x00000000162fa55a 26. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc6653 27. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000000fccc4c3 28. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc3d92 29. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fcca080 30. ? @ 0x00007fbc6213eac3 31. ? @ 0x00007fbc621d0850 (version 25.3.6.10636.altinitytest (altinity build)) 2025.07.28 12:02:20.178721 [ 62053 ] {71319aeb-b079-42a9-9813-9ebd0c9b334f} executeQuery: Code: 394. DB::Exception: Query was cancelled. (QUERY_WAS_CANCELLED) (version 25.3.6.10636.altinitytest (altinity build)) (from [::1]:45588) (comment: 02461_cancel_finish_race.sh) (query 1, line 1) (in query: KILL QUERY WHERE current_database = 'test_dtwle8fg' SYNC FORMAT Null), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000000a074fcb 4. /build/src/Interpreters/ProcessList.cpp:567: DB::QueryStatus::throwQueryWasCancelled() const @ 0x0000000014a4bc85 5. /build/src/Interpreters/ProcessList.cpp:520: DB::QueryStatus::throwProperExceptionIfNeeded(unsigned long const&, unsigned long const&) @ 0x0000000014a4bbd9 6. /build/src/Interpreters/ProcessList.cpp:531: DB::QueryStatus::addPipelineExecutor(DB::PipelineExecutor*) @ 0x0000000014a4bd9c 7. /build/src/Processors/Executors/PipelineExecutor.cpp:73: DB::PipelineExecutor::PipelineExecutor(std::shared_ptr, std::allocator>>>&, std::shared_ptr) @ 0x00000000169afe31 8. /build/contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x00000000169bef66 9. /build/src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x00000000169bf518 10. /build/src/Server/TCPHandler.cpp:1237: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x00000000168f1525 11. /build/src/Server/TCPHandler.cpp:678: DB::TCPHandler::runImpl() @ 0x00000000168e68e5 12. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 13. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 14. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 16. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 17. ? @ 0x00007fbc6213eac3 18. ? @ 0x00007fbc621d0850 2025.07.28 12:02:20.270040 [ 62053 ] {} TCPHandler: Code: 394. DB::Exception: Query was cancelled. (QUERY_WAS_CANCELLED), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000000a074fcb 4. /build/src/Interpreters/ProcessList.cpp:567: DB::QueryStatus::throwQueryWasCancelled() const @ 0x0000000014a4bc85 5. /build/src/Interpreters/ProcessList.cpp:520: DB::QueryStatus::throwProperExceptionIfNeeded(unsigned long const&, unsigned long const&) @ 0x0000000014a4bbd9 6. /build/src/Interpreters/ProcessList.cpp:531: DB::QueryStatus::addPipelineExecutor(DB::PipelineExecutor*) @ 0x0000000014a4bd9c 7. /build/src/Processors/Executors/PipelineExecutor.cpp:73: DB::PipelineExecutor::PipelineExecutor(std::shared_ptr, std::allocator>>>&, std::shared_ptr) @ 0x00000000169afe31 8. /build/contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x00000000169bef66 9. /build/src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x00000000169bf518 10. /build/src/Server/TCPHandler.cpp:1237: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x00000000168f1525 11. /build/src/Server/TCPHandler.cpp:678: DB::TCPHandler::runImpl() @ 0x00000000168e68e5 12. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 13. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 14. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 16. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 17. ? @ 0x00007fbc6213eac3 18. ? @ 0x00007fbc621d0850 2025.07.28 12:02:20.290684 [ 17256 ] {a02b07fa-5a87-4765-93cb-93d39cb3edf8} executeQuery: Code: 394. DB::Exception: Query was cancelled. (QUERY_WAS_CANCELLED) (version 25.3.6.10636.altinitytest (altinity build)) (from [::1]:45600) (comment: 02461_cancel_finish_race.sh) (query 1, line 1) (in query: KILL QUERY WHERE current_database = 'test_dtwle8fg' SYNC FORMAT Null), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000000a074fcb 4. /build/src/Interpreters/ProcessList.cpp:567: DB::QueryStatus::throwQueryWasCancelled() const @ 0x0000000014a4bc85 5. /build/src/Interpreters/ProcessList.cpp:520: DB::QueryStatus::throwProperExceptionIfNeeded(unsigned long const&, unsigned long const&) @ 0x0000000014a4bbd9 6. /build/src/Interpreters/ProcessList.cpp:557: DB::QueryStatus::checkTimeLimit() @ 0x0000000014a4c2cd 7. /build/src/Processors/Executors/PipelineExecutor.cpp:206: DB::PipelineExecutor::finalizeExecution() @ 0x00000000169b13ba 8. /build/src/Processors/Executors/PipelineExecutor.cpp:153: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x00000000169b0584 9. /build/src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:se190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169bfeab 10. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc3d92 11. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fcca080 12. ? @ 0x00007fbc6213eac3 13. ? @ 0x00007fbc621d0850 2025.07.28 12:02:20.295736 [ 17256 ] {} TCPHandler: Code: 394. DB::Exception: Query was cancelled. (QUERY_WAS_CANCELLED), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000000a074fcb 4. /build/src/Interpreters/ProcessList.cpp:567: DB::QueryStatus::throwQueryWasCancelled() const @ 0x0000000014a4bc85 5. /build/src/Interpreters/ProcessList.cpp:520: DB::QueryStatus::throwProperExceptionIfNeeded(unsigned long const&, unsigned long const&) @ 0x0000000014a4bbd9 6. /build/src/Interpreters/ProcessList.cpp:557: DB::QueryStatus::checkTimeLimit() @ 0x0000000014a4c2cd 7. /build/src/Processors/Executors/PipelineExecutor.cpp:206: DB::PipelineExecutor::finalizeExecution() @ 0x00000000169b13ba 8. /build/src/Processors/Executors/PipelineExecutor.cpp:153: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x00000000169b0584 9. /build/src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:se190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169bfeab 10. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc3d92 11. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fcca080 12. ? @ 0x00007fbc6213eac3 13. ? @ 0x00007fbc621d0850 Job's origin stack trace: 0. /build/src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000000fc33b84 1. /build/src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000000fcc2ea7 2. /build/src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fcc535c 3. /build/src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000000fcc584d 4. /build/src/Common/ThreadPool.h:279: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x00000000169bf193 5. /build/src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x00000000169bf518 6. /build/src/Server/TCPHandler.cpp:1237: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x00000000168f1525 7. /build/src/Server/TCPHandler.cpp:678: DB::TCPHandler::runImpl() @ 0x00000000168e68e5 8. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 9. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 10. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 11. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 12. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 13. ? @ 0x00007fbc6213eac3 14. ? @ 0x00007fbc621d0850 2025.07.28 12:02:20.337646 [ 62114 ] {76f81b0d-e44a-4a6f-b7e0-4752ec521347} executeQuery: Code: 394. DB::Exception: Query was cancelled. (QUERY_WAS_CANCELLED) (version 25.3.6.10636.altinitytest (altinity build)) (from [::1]:45690) (comment: 02461_cancel_finish_race.sh) (query 1, line 1) (in query: KILL QUERY WHERE current_database = 'test_dtwle8fg' SYNC FORMAT Null), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000000a074fcb 4. /build/src/Interpreters/ProcessList.cpp:567: DB::QueryStatus::throwQueryWasCancelled() const @ 0x0000000014a4bc85 5. /build/src/Interpreters/ProcessList.cpp:520: DB::QueryStatus::throwProperExceptionIfNeeded(unsigned long const&, unsigned long const&) @ 0x0000000014a4bbd9 6. /build/src/Interpreters/ProcessList.cpp:557: DB::QueryStatus::checkTimeLimit() @ 0x0000000014a4c2cd 7. /build/src/Processors/Executors/PipelineExecutor.cpp:206: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x00000000169b03a3 8. /build/src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:se190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169bfeab 9. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc3d92 10. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fcca080 11. ? @ 0x00007fbc6213eac3 12. ? @ 0x00007fbc621d0850 2025.07.28 12:02:20.342754 [ 7625 ] {7ef2751e-b970-4f4b-90ad-be813bfe3aea} executeQuery: Code: 394. DB::Exception: Query was cancelled. (QUERY_WAS_CANCELLED) (version 25.3.6.10636.altinitytest (altinity build)) (from [::1]:45676) (comment: 02461_cancel_finish_race.sh) (query 1, line 1) (in query: KILL QUERY WHERE current_database = 'test_dtwle8fg' SYNC FORMAT Null), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000000a074fcb 4. /build/src/Interpreters/ProcessList.cpp:567: DB::QueryStatus::throwQueryWasCancelled() const @ 0x0000000014a4bc85 5. /build/src/Interpreters/ProcessList.cpp:520: DB::QueryStatus::throwProperExceptionIfNeeded(unsigned long const&, unsigned long const&) @ 0x0000000014a4bbd9 6. /build/src/Interpreters/ProcessList.cpp:557: DB::QueryStatus::checkTimeLimit() @ 0x0000000014a4c2cd 7. /build/src/Processors/Executors/PipelineExecutor.cpp:206: DB::PipelineExecutor::finalizeExecution() @ 0x00000000169b13ba 8. /build/src/Processors/Executors/PipelineExecutor.cpp:153: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x00000000169b0584 9. /build/src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:se190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169bfeab 10. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc3d92 11. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fcca080 12. ? @ 0x00007fbc6213eac3 13. ? @ 0x00007fbc621d0850 2025.07.28 12:02:20.358659 [ 7625 ] {} TCPHandler: Code: 394. DB::Exception: Query was cancelled. (QUERY_WAS_CANCELLED), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000000a074fcb 4. /build/src/Interpreters/ProcessList.cpp:567: DB::QueryStatus::throwQueryWasCancelled() const @ 0x0000000014a4bc85 5. /build/src/Interpreters/ProcessList.cpp:520: DB::QueryStatus::throwProperExceptionIfNeeded(unsigned long const&, unsigned long const&) @ 0x0000000014a4bbd9 6. /build/src/Interpreters/ProcessList.cpp:557: DB::QueryStatus::checkTimeLimit() @ 0x0000000014a4c2cd 7. /build/src/Processors/Executors/PipelineExecutor.cpp:206: DB::PipelineExecutor::finalizeExecution() @ 0x00000000169b13ba 8. /build/src/Processors/Executors/PipelineExecutor.cpp:153: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x00000000169b0584 9. /build/src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:se190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169bfeab 10. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc3d92 11. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fcca080 12. ? @ 0x00007fbc6213eac3 13. ? @ 0x00007fbc621d0850 Job's origin stack trace: 0. /build/src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000000fc33b84 1. /build/src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000000fcc2ea7 2. /build/src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fcc535c 3. /build/src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000000fcc584d 4. /build/src/Common/ThreadPool.h:279: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x00000000169bf193 5. /build/src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x00000000169bf518 6. /build/src/Server/TCPHandler.cpp:1237: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x00000000168f1525 7. /build/src/Server/TCPHandler.cpp:678: DB::TCPHandler::runImpl() @ 0x00000000168e68e5 8. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 9. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 10. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 11. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 12. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 13. ? @ 0x00007fbc6213eac3 14. ? @ 0x00007fbc621d0850 2025.07.28 12:02:20.424112 [ 62114 ] {} TCPHandler: Code: 394. DB::Exception: Query was cancelled. (QUERY_WAS_CANCELLED), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000000a074fcb 4. /build/src/Interpreters/ProcessList.cpp:567: DB::QueryStatus::throwQueryWasCancelled() const @ 0x0000000014a4bc85 5. /build/src/Interpreters/ProcessList.cpp:520: DB::QueryStatus::throwProperExceptionIfNeeded(unsigned long const&, unsigned long const&) @ 0x0000000014a4bbd9 6. /build/src/Interpreters/ProcessList.cpp:557: DB::QueryStatus::checkTimeLimit() @ 0x0000000014a4c2cd 7. /build/src/Processors/Executors/PipelineExecutor.cpp:206: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x00000000169b03a3 8. /build/src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:se190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169bfeab 9. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc3d92 10. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fcca080 11. ? @ 0x00007fbc6213eac3 12. ? @ 0x00007fbc621d0850 Job's origin stack trace: 0. /build/src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000000fc33b84 1. /build/src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000000fcc2ea7 2. /build/src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fcc535c 3. /build/src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000000fcc584d 4. /build/src/Common/ThreadPool.h:279: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x00000000169bf193 5. /build/src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x00000000169bf518 6. /build/src/Server/TCPHandler.cpp:1237: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x00000000168f1525 7. /build/src/Server/TCPHandler.cpp:678: DB::TCPHandler::runImpl() @ 0x00000000168e68e5 8. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 9. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 10. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 11. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 12. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 13. ? @ 0x00007fbc6213eac3 14. ? @ 0x00007fbc621d0850 2025.07.28 12:02:20.442140 [ 4900 ] {f01007df-49af-4894-9c75-d61e44ddd451} executeQuery: Code: 394. DB::Exception: Query was cancelled. (QUERY_WAS_CANCELLED) (version 25.3.6.10636.altinitytest (altinity build)) (from [::1]:45620) (comment: 02461_cancel_finish_race.sh) (query 1, line 1) (in query: KILL QUERY WHERE current_database = 'test_dtwle8fg' SYNC FORMAT Null), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000000a074fcb 4. /build/src/Interpreters/ProcessList.cpp:567: DB::QueryStatus::throwQueryWasCancelled() const @ 0x0000000014a4bc85 5. /build/src/Interpreters/ProcessList.cpp:520: DB::QueryStatus::throwProperExceptionIfNeeded(unsigned long const&, unsigned long const&) @ 0x0000000014a4bbd9 6. /build/src/Interpreters/ProcessList.cpp:557: DB::QueryStatus::checkTimeLimit() @ 0x0000000014a4c2cd 7. /build/src/Processors/Executors/PipelineExecutor.cpp:206: DB::PipelineExecutor::finalizeExecution() @ 0x00000000169b13ba 8. /build/src/Processors/Executors/PipelineExecutor.cpp:153: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x00000000169b0584 9. /build/src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:se190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169bfeab 10. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc3d92 11. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fcca080 12. ? @ 0x00007fbc6213eac3 13. ? @ 0x00007fbc621d0850 2025.07.28 12:02:20.504153 [ 17203 ] {07cd1063-6678-449a-9dc8-2d81d5764167} executeQuery: Code: 394. DB::Exception: Query was cancelled. (QUERY_WAS_CANCELLED) (version 25.3.6.10636.altinitytest (altinity build)) (from [::1]:45758) (comment: 02461_cancel_finish_race.sh) (query 1, line 1) (in query: KILL QUERY WHERE current_database = 'test_dtwle8fg' SYNC FORMAT Null), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000000a074fcb 4. /build/src/Interpreters/ProcessList.cpp:567: DB::QueryStatus::throwQueryWasCancelled() const @ 0x0000000014a4bc85 5. /build/src/Interpreters/ProcessList.cpp:520: DB::QueryStatus::throwProperExceptionIfNeeded(unsigned long const&, unsigned long const&) @ 0x0000000014a4bbd9 6. /build/src/Interpreters/ProcessList.cpp:531: DB::QueryStatus::addPipelineExecutor(DB::PipelineExecutor*) @ 0x0000000014a4bd9c 7. /build/src/Processors/Executors/PipelineExecutor.cpp:73: DB::PipelineExecutor::PipelineExecutor(std::shared_ptr, std::allocator>>>&, std::shared_ptr) @ 0x00000000169afe31 8. /build/contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x00000000169bef66 9. /build/src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x00000000169bf518 10. /build/src/Server/TCPHandler.cpp:1237: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x00000000168f1525 11. /build/src/Server/TCPHandler.cpp:678: DB::TCPHandler::runImpl() @ 0x00000000168e68e5 12. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 13. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 14. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 16. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 17. ? @ 0x00007fbc6213eac3 18. ? @ 0x00007fbc621d0850 2025.07.28 12:02:20.507917 [ 62056 ] {} TCPHandler: Code: 394. DB::Exception: Query was cancelled. (QUERY_WAS_CANCELLED), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000000a074fcb 4. /build/src/Interpreters/ProcessList.cpp:567: DB::QueryStatus::throwQueryWasCancelled() const @ 0x0000000014a4bc85 5. /build/src/Interpreters/ProcessList.cpp:520: DB::QueryStatus::throwProperExceptionIfNeeded(unsigned long const&, unsigned long const&) @ 0x0000000014a4bbd9 6. /build/src/Interpreters/ProcessList.cpp:531: DB::QueryStatus::addPipelineExecutor(DB::PipelineExecutor*) @ 0x0000000014a4bd9c 7. /build/src/Processors/Executors/PipelineExecutor.cpp:73: DB::PipelineExecutor::PipelineExecutor(std::shared_ptr, std::allocator>>>&, std::shared_ptr) @ 0x00000000169afe31 8. /build/contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x00000000169c07b5 9. /build/src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x00000000169c0978 10. /build/src/Interpreters/InterpreterKillQueryQuery.cpp:439: DB::InterpreterKillQueryQuery::getSelectResult(String const&, String const&) @ 0x0000000014cf0f04 11. /build/src/Interpreters/InterpreterKillQueryQuery.cpp:222: DB::InterpreterKillQueryQuery::execute() @ 0x0000000014cebde2 12. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88dc9 13. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 14. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 15. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 16. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 17. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 18. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 19. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 20. ? @ 0x00007fbc6213eac3 21. ? @ 0x00007fbc621d0850 2025.07.28 12:02:20.508853 [ 4900 ] {} TCPHandler: Code: 394. DB::Exception: Query was cancelled. (QUERY_WAS_CANCELLED), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000000a074fcb 4. /build/src/Interpreters/ProcessList.cpp:567: DB::QueryStatus::throwQueryWasCancelled() const @ 0x0000000014a4bc85 5. /build/src/Interpreters/ProcessList.cpp:520: DB::QueryStatus::throwProperExceptionIfNeeded(unsigned long const&, unsigned long const&) @ 0x0000000014a4bbd9 6. /build/src/Interpreters/ProcessList.cpp:557: DB::QueryStatus::checkTimeLimit() @ 0x0000000014a4c2cd 7. /build/src/Processors/Executors/PipelineExecutor.cpp:206: DB::PipelineExecutor::finalizeExecution() @ 0x00000000169b13ba 8. /build/src/Processors/Executors/PipelineExecutor.cpp:153: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x00000000169b0584 9. /build/src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:se190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169bfeab 10. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc3d92 11. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fcca080 12. ? @ 0x00007fbc6213eac3 13. ? @ 0x00007fbc621d0850 Job's origin stack trace: 0. /build/src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000000fc33b84 1. /build/src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000000fcc2ea7 2. /build/src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fcc535c 3. /build/src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000000fcc584d 4. /build/src/Common/ThreadPool.h:279: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x00000000169bf193 5. /build/src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x00000000169bf518 6. /build/src/Server/TCPHandler.cpp:1237: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x00000000168f1525 7. /build/src/Server/TCPHandler.cpp:678: DB::TCPHandler::runImpl() @ 0x00000000168e68e5 8. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 9. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 10. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 11. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 12. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 13. ? @ 0x00007fbc6213eac3 14. ? @ 0x00007fbc621d0850 2025.07.28 12:02:20.530540 [ 17203 ] {} TCPHandler: Code: 394. DB::Exception: Query was cancelled. (QUERY_WAS_CANCELLED), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000000a074fcb 4. /build/src/Interpreters/ProcessList.cpp:567: DB::QueryStatus::throwQueryWasCancelled() const @ 0x0000000014a4bc85 5. /build/src/Interpreters/ProcessList.cpp:520: DB::QueryStatus::throwProperExceptionIfNeeded(unsigned long const&, unsigned long const&) @ 0x0000000014a4bbd9 6. /build/src/Interpreters/ProcessList.cpp:531: DB::QueryStatus::addPipelineExecutor(DB::PipelineExecutor*) @ 0x0000000014a4bd9c 7. /build/src/Processors/Executors/PipelineExecutor.cpp:73: DB::PipelineExecutor::PipelineExecutor(std::shared_ptr, std::allocator>>>&, std::shared_ptr) @ 0x00000000169afe31 8. /build/contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x00000000169bef66 9. /build/src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x00000000169bf518 10. /build/src/Server/TCPHandler.cpp:1237: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x00000000168f1525 11. /build/src/Server/TCPHandler.cpp:678: DB::TCPHandler::runImpl() @ 0x00000000168e68e5 12. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 13. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 14. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 16. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 17. ? @ 0x00007fbc6213eac3 18. ? @ 0x00007fbc621d0850 2025.07.28 12:02:20.570068 [ 62065 ] {6830f563-3440-460d-baff-2c2d64ab21f2} executeQuery: Code: 394. DB::Exception: Query was cancelled. (QUERY_WAS_CANCELLED) (version 25.3.6.10636.altinitytest (altinity build)) (from [::1]:45784) (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. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000000a074fcb 4. /build/src/Interpreters/ProcessList.cpp:567: DB::QueryStatus::throwQueryWasCancelled() const @ 0x0000000014a4bc85 5. /build/src/Interpreters/ProcessList.cpp:520: DB::QueryStatus::throwProperExceptionIfNeeded(unsigned long const&, unsigned long const&) @ 0x0000000014a4bbd9 6. /build/src/Interpreters/ProcessList.cpp:557: DB::QueryStatus::checkTimeLimit() @ 0x0000000014a4c2cd 7. /build/src/Processors/Executors/PipelineExecutor.cpp:206: DB::PipelineExecutor::finalizeExecution() @ 0x00000000169b13ba 8. /build/src/Processors/Executors/PipelineExecutor.cpp:153: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x00000000169b0584 9. /build/src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:se190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169bfeab 10. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc3d92 11. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fcca080 12. ? @ 0x00007fbc6213eac3 13. ? @ 0x00007fbc621d0850 2025.07.28 12:02:20.582515 [ 62065 ] {} TCPHandler: Code: 394. DB::Exception: Query was cancelled. (QUERY_WAS_CANCELLED), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000000a074fcb 4. /build/src/Interpreters/ProcessList.cpp:567: DB::QueryStatus::throwQueryWasCancelled() const @ 0x0000000014a4bc85 5. /build/src/Interpreters/ProcessList.cpp:520: DB::QueryStatus::throwProperExceptionIfNeeded(unsigned long const&, unsigned long const&) @ 0x0000000014a4bbd9 6. /build/src/Interpreters/ProcessList.cpp:557: DB::QueryStatus::checkTimeLimit() @ 0x0000000014a4c2cd 7. /build/src/Processors/Executors/PipelineExecutor.cpp:206: DB::PipelineExecutor::finalizeExecution() @ 0x00000000169b13ba 8. /build/src/Processors/Executors/PipelineExecutor.cpp:153: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x00000000169b0584 9. /build/src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:se190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169bfeab 10. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc3d92 11. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fcca080 12. ? @ 0x00007fbc6213eac3 13. ? @ 0x00007fbc621d0850 Job's origin stack trace: 0. /build/src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000000fc33b84 1. /build/src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000000fcc2ea7 2. /build/src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fcc535c 3. /build/src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000000fcc584d 4. /build/src/Common/ThreadPool.h:279: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x00000000169bf193 5. /build/src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x00000000169bf518 6. /build/src/Server/TCPHandler.cpp:1237: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x00000000168f1525 7. /build/src/Server/TCPHandler.cpp:678: DB::TCPHandler::runImpl() @ 0x00000000168e68e5 8. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 9. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 10. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 11. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 12. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 13. ? @ 0x00007fbc6213eac3 14. ? @ 0x00007fbc621d0850 2025.07.28 12:02:20.597358 [ 17371 ] {b3ced437-7d72-4f5d-b0fe-d47202329e68} executeQuery: Code: 394. DB::Exception: Query was cancelled. (QUERY_WAS_CANCELLED) (version 25.3.6.10636.altinitytest (altinity build)) (from [::1]:45754) (comment: 02461_cancel_finish_race.sh) (query 1, line 1) (in query: KILL QUERY WHERE current_database = 'test_dtwle8fg' SYNC FORMAT Null), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000000a074fcb 4. /build/src/Interpreters/ProcessList.cpp:567: DB::QueryStatus::throwQueryWasCancelled() const @ 0x0000000014a4bc85 5. /build/src/Interpreters/ProcessList.cpp:520: DB::QueryStatus::throwProperExceptionIfNeeded(unsigned long const&, unsigned long const&) @ 0x0000000014a4bbd9 6. /build/src/Interpreters/ProcessList.cpp:557: DB::QueryStatus::checkTimeLimit() @ 0x0000000014a4c2cd 7. /build/src/Processors/Executors/PipelineExecutor.cpp:206: DB::PipelineExecutor::finalizeExecution() @ 0x00000000169b13ba 8. /build/src/Processors/Executors/PipelineExecutor.cpp:153: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x00000000169b0584 9. /build/src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:se190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169bfeab 10. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc3d92 11. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fcca080 12. ? @ 0x00007fbc6213eac3 13. ? @ 0x00007fbc621d0850 2025.07.28 12:02:20.617667 [ 17371 ] {} TCPHandler: Code: 394. DB::Exception: Query was cancelled. (QUERY_WAS_CANCELLED), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000000a074fcb 4. /build/src/Interpreters/ProcessList.cpp:567: DB::QueryStatus::throwQueryWasCancelled() const @ 0x0000000014a4bc85 5. /build/src/Interpreters/ProcessList.cpp:520: DB::QueryStatus::throwProperExceptionIfNeeded(unsigned long const&, unsigned long const&) @ 0x0000000014a4bbd9 6. /build/src/Interpreters/ProcessList.cpp:557: DB::QueryStatus::checkTimeLimit() @ 0x0000000014a4c2cd 7. /build/src/Processors/Executors/PipelineExecutor.cpp:206: DB::PipelineExecutor::finalizeExecution() @ 0x00000000169b13ba 8. /build/src/Processors/Executors/PipelineExecutor.cpp:153: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x00000000169b0584 9. /build/src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:se190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169bfeab 10. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc3d92 11. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fcca080 12. ? @ 0x00007fbc6213eac3 13. ? @ 0x00007fbc621d0850 Job's origin stack trace: 0. /build/src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000000fc33b84 1. /build/src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000000fcc2ea7 2. /build/src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fcc535c 3. /build/src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000000fcc584d 4. /build/src/Common/ThreadPool.h:279: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x00000000169bf193 5. /build/src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x00000000169bf518 6. /build/src/Server/TCPHandler.cpp:1237: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x00000000168f1525 7. /build/src/Server/TCPHandler.cpp:678: DB::TCPHandler::runImpl() @ 0x00000000168e68e5 8. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 9. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 10. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 11. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 12. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 13. ? @ 0x00007fbc6213eac3 14. ? @ 0x00007fbc621d0850 2025.07.28 12:02:20.740188 [ 5879 ] {} TCPHandler: Code: 394. DB::Exception: Query was cancelled. (QUERY_WAS_CANCELLED), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000000a074fcb 4. /build/src/Interpreters/ProcessList.cpp:567: DB::QueryStatus::throwQueryWasCancelled() const @ 0x0000000014a4bc85 5. /build/src/Interpreters/ProcessList.cpp:520: DB::QueryStatus::throwProperExceptionIfNeeded(unsigned long const&, unsigned long const&) @ 0x0000000014a4bbd9 6. /build/src/Interpreters/ProcessList.cpp:531: DB::QueryStatus::addPipelineExecutor(DB::PipelineExecutor*) @ 0x0000000014a4bd9c 7. /build/src/Processors/Executors/PipelineExecutor.cpp:73: DB::PipelineExecutor::PipelineExecutor(std::shared_ptr, std::allocator>>>&, std::shared_ptr) @ 0x00000000169afe31 8. /build/contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x00000000169c07b5 9. /build/src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x00000000169c0978 10. /build/src/Interpreters/InterpreterKillQueryQuery.cpp:439: DB::InterpreterKillQueryQuery::getSelectResult(String const&, String const&) @ 0x0000000014cf0f04 11. /build/src/Interpreters/InterpreterKillQueryQuery.cpp:222: DB::InterpreterKillQueryQuery::execute() @ 0x0000000014cebde2 12. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88dc9 13. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 14. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 15. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 16. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 17. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 18. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 19. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 20. ? @ 0x00007fbc6213eac3 21. ? @ 0x00007fbc621d0850 2025.07.28 12:02:20.817998 [ 3963 ] {} test_13.rmt2 (7f9b740d-015c-470e-8cc6-8ba33be0dc63): auto DB::StorageReplicatedMergeTree::processQueueEntry(ReplicatedMergeTreeQueue::SelectedEntryPtr)::(anonymous class)::operator()(LogEntryPtr &) const: Code: 86. DB::HTTPException: Received error from remote server http://146b4357c08d:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Ftest%2F01165%2Ftest_13%2Frmt%2Freplicas%2F1&part=20250728_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.6.10636.altinitytest (altinity build)) '. (RECEIVED_ERROR_FROM_REMOTE_IO_SERVER), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.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 const&, int&&, String const&, unsigned long&&, String const&) @ 0x000000000feda8d9 4. /build/src/IO/HTTPCommon.cpp:104: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x000000000feda6e2 5. /build/src/IO/HTTPCommon.cpp:93: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x000000000feda537 6. /build/src/IO/ReadWriteBufferFromHTTP.cpp:277: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x000000001184a4c4 7. /build/src/IO/ReadWriteBufferFromHTTP.cpp:285: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x000000001184a615 8. /build/src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x000000001184ae59 9. /build/src/IO/ReadWriteBufferFromHTTP.cpp:472: void std::__function::__policy_invoker::__call_impl[abi:se190107]>(std::__function::__policy_storage const*) @ 0x000000001184cedd 10. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001184858b 11. /build/src/IO/ReadWriteBufferFromHTTP.cpp:465: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x000000001184bf0b 12. /build/src/IO/ReadBuffer.h:60: DB::ReadBuffer::next() @ 0x000000000a148c7b 13. /build/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) @ 0x0000000011849fb2 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]>&)>&, 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&) @ 0x0000000011841980 15. /build/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) @ 0x000000001621208e 16. /build/src/Storages/StorageReplicatedMergeTree.cpp:5228: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl[abi:se190107] const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000015f9a5fe 17. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000015ed8bfd 18. /build/src/Storages/StorageReplicatedMergeTree.cpp:2514: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x0000000015ec9aab 19. /build/src/Storages/StorageReplicatedMergeTree.cpp:2349: DB::StorageReplicatedMergeTree::executeLogEntry(DB::ReplicatedMergeTreeLogEntry&) @ 0x0000000015eba91b 20. /build/src/Storages/StorageReplicatedMergeTree.cpp:3876: bool std::__function::__policy_invoker&)>::__call_impl[abi:se190107])::$_1, bool (std::shared_ptr&)>>(std::__function::__policy_storage const*, std::shared_ptr&) @ 0x0000000015f9837e 21. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000165d6fc3 22. /build/src/Storages/StorageReplicatedMergeTree.cpp:3872: DB::StorageReplicatedMergeTree::processQueueEntry(std::shared_ptr) @ 0x0000000015efc18a 23. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001624c1b2 24. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000162f9c70 25. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x00000000162fa55a 26. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc6653 27. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000000fccc4c3 28. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc3d92 29. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fcca080 30. ? @ 0x00007fbc6213eac3 31. ? @ 0x00007fbc621d0850 (version 25.3.6.10636.altinitytest (altinity build)) 2025.07.28 12:02:20.887462 [ 62093 ] {6dc319be-9f90-4c25-be89-ef01626ccf8b} executeQuery: Code: 394. DB::Exception: Query was cancelled. (QUERY_WAS_CANCELLED) (version 25.3.6.10636.altinitytest (altinity build)) (from [::1]:45838) (comment: 02461_cancel_finish_race.sh) (query 1, line 1) (in query: KILL QUERY WHERE current_database = 'test_dtwle8fg' SYNC FORMAT Null), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000000a074fcb 4. /build/src/Interpreters/ProcessList.cpp:567: DB::QueryStatus::throwQueryWasCancelled() const @ 0x0000000014a4bc85 5. /build/src/Interpreters/ProcessList.cpp:520: DB::QueryStatus::throwProperExceptionIfNeeded(unsigned long const&, unsigned long const&) @ 0x0000000014a4bbd9 6. /build/src/Interpreters/ProcessList.cpp:557: DB::QueryStatus::checkTimeLimit() @ 0x0000000014a4c2cd 7. /build/src/Processors/Executors/PipelineExecutor.cpp:206: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x00000000169b03a3 8. /build/src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:se190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169bfeab 9. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc3d92 10. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fcca080 11. ? @ 0x00007fbc6213eac3 12. ? @ 0x00007fbc621d0850 2025.07.28 12:02:20.922161 [ 62093 ] {} TCPHandler: Code: 394. DB::Exception: Query was cancelled. (QUERY_WAS_CANCELLED), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000000a074fcb 4. /build/src/Interpreters/ProcessList.cpp:567: DB::QueryStatus::throwQueryWasCancelled() const @ 0x0000000014a4bc85 5. /build/src/Interpreters/ProcessList.cpp:520: DB::QueryStatus::throwProperExceptionIfNeeded(unsigned long const&, unsigned long const&) @ 0x0000000014a4bbd9 6. /build/src/Interpreters/ProcessList.cpp:557: DB::QueryStatus::checkTimeLimit() @ 0x0000000014a4c2cd 7. /build/src/Processors/Executors/PipelineExecutor.cpp:206: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x00000000169b03a3 8. /build/src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:se190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169bfeab 9. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc3d92 10. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fcca080 11. ? @ 0x00007fbc6213eac3 12. ? @ 0x00007fbc621d0850 Job's origin stack trace: 0. /build/src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000000fc33b84 1. /build/src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000000fcc2ea7 2. /build/src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fcc535c 3. /build/src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000000fcc584d 4. /build/src/Common/ThreadPool.h:279: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x00000000169bf193 5. /build/src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x00000000169bf518 6. /build/src/Server/TCPHandler.cpp:1237: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x00000000168f1525 7. /build/src/Server/TCPHandler.cpp:678: DB::TCPHandler::runImpl() @ 0x00000000168e68e5 8. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 9. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 10. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 11. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 12. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 13. ? @ 0x00007fbc6213eac3 14. ? @ 0x00007fbc621d0850 2025.07.28 12:02:20.940764 [ 17255 ] {} TCPHandler: Code: 394. DB::Exception: Query was cancelled. (QUERY_WAS_CANCELLED), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000000a074fcb 4. /build/src/Interpreters/ProcessList.cpp:567: DB::QueryStatus::throwQueryWasCancelled() const @ 0x0000000014a4bc85 5. /build/src/Interpreters/ProcessList.cpp:520: DB::QueryStatus::throwProperExceptionIfNeeded(unsigned long const&, unsigned long const&) @ 0x0000000014a4bbd9 6. /build/src/Interpreters/ProcessList.cpp:557: DB::QueryStatus::checkTimeLimit() @ 0x0000000014a4c2cd 7. /build/src/Processors/Executors/PipelineExecutor.cpp:206: DB::PipelineExecutor::finalizeExecution() @ 0x00000000169b13ba 8. /build/src/Processors/Executors/PipelineExecutor.cpp:181: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x00000000169b1726 9. /build/src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x00000000169c081c 10. /build/src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x00000000169c0978 11. /build/src/Interpreters/InterpreterKillQueryQuery.cpp:442: DB::InterpreterKillQueryQuery::getSelectResult(String const&, String const&) @ 0x0000000014cf0f6b 12. /build/src/Interpreters/InterpreterKillQueryQuery.cpp:222: DB::InterpreterKillQueryQuery::execute() @ 0x0000000014cebde2 13. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88dc9 14. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 15. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 16. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 17. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 18. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 19. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 20. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 21. ? @ 0x00007fbc6213eac3 22. ? @ 0x00007fbc621d0850 2025.07.28 12:02:21.043796 [ 17256 ] {40ecb188-023e-4aa1-b4e4-fa6141e34ac4} executeQuery: Code: 394. DB::Exception: Query was cancelled. (QUERY_WAS_CANCELLED) (version 25.3.6.10636.altinitytest (altinity build)) (from [::1]:45840) (comment: 02461_cancel_finish_race.sh) (query 1, line 1) (in query: KILL QUERY WHERE current_database = 'test_dtwle8fg' SYNC FORMAT Null), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000000a074fcb 4. /build/src/Interpreters/ProcessList.cpp:567: DB::QueryStatus::throwQueryWasCancelled() const @ 0x0000000014a4bc85 5. /build/src/Interpreters/ProcessList.cpp:520: DB::QueryStatus::throwProperExceptionIfNeeded(unsigned long const&, unsigned long const&) @ 0x0000000014a4bbd9 6. /build/src/Interpreters/ProcessList.cpp:557: DB::QueryStatus::checkTimeLimit() @ 0x0000000014a4c2cd 7. /build/src/Processors/Executors/PipelineExecutor.cpp:206: DB::PipelineExecutor::finalizeExecution() @ 0x00000000169b13ba 8. /build/src/Processors/Executors/PipelineExecutor.cpp:153: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x00000000169b0584 9. /build/src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:se190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169bfeab 10. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc3d92 11. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fcca080 12. ? @ 0x00007fbc6213eac3 13. ? @ 0x00007fbc621d0850 2025.07.28 12:02:21.077854 [ 17256 ] {} TCPHandler: Code: 394. DB::Exception: Query was cancelled. (QUERY_WAS_CANCELLED), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000000a074fcb 4. /build/src/Interpreters/ProcessList.cpp:567: DB::QueryStatus::throwQueryWasCancelled() const @ 0x0000000014a4bc85 5. /build/src/Interpreters/ProcessList.cpp:520: DB::QueryStatus::throwProperExceptionIfNeeded(unsigned long const&, unsigned long const&) @ 0x0000000014a4bbd9 6. /build/src/Interpreters/ProcessList.cpp:557: DB::QueryStatus::checkTimeLimit() @ 0x0000000014a4c2cd 7. /build/src/Processors/Executors/PipelineExecutor.cpp:206: DB::PipelineExecutor::finalizeExecution() @ 0x00000000169b13ba 8. /build/src/Processors/Executors/PipelineExecutor.cpp:153: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x00000000169b0584 9. /build/src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:se190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169bfeab 10. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc3d92 11. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fcca080 12. ? @ 0x00007fbc6213eac3 13. ? @ 0x00007fbc621d0850 Job's origin stack trace: 0. /build/src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000000fc33b84 1. /build/src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000000fcc2ea7 2. /build/src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fcc535c 3. /build/src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000000fcc584d 4. /build/src/Common/ThreadPool.h:279: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x00000000169bf193 5. /build/src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x00000000169bf518 6. /build/src/Server/TCPHandler.cpp:1237: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x00000000168f1525 7. /build/src/Server/TCPHandler.cpp:678: DB::TCPHandler::runImpl() @ 0x00000000168e68e5 8. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 9. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 10. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 11. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 12. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 13. ? @ 0x00007fbc6213eac3 14. ? @ 0x00007fbc621d0850 2025.07.28 12:02:21.092440 [ 62058 ] {82f6c25d-9e45-4b15-85ef-fc03fd8f5497} executeQuery: Code: 403. DB::Exception: Cannot get JOIN keys from JOIN ON section: 'vx.c0', found keys: [Left keys: [] Right keys [] Condition columns: '', 'vx.c0']: While processing SELECT 1 FROM (SELECT 1 AS c0) AS v0 ALL INNER JOIN v0 AS vx ON vx.c0. (INVALID_JOIN_ON_EXPRESSION) (version 25.3.6.10636.altinitytest (altinity build)) (from [::1]:45734) (comment: 03274_udf_in_join.sh) (query 5, line 7) (in query: EXPLAIN SYNTAX SELECT 1 FROM v0 JOIN v0 vx ON test_cxjc1csm_second(v0.c0, vx.c0);), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000a06a8eb 4. /build/src/Interpreters/TreeRewriter.cpp:724: DB::TreeRewriter::analyzeSelect(std::shared_ptr&, DB::TreeRewriterResult&&, DB::SelectQueryOptions const&, std::vector> const&, std::vector> const&, std::shared_ptr) const @ 0x0000000014c07505 5. /build/src/Interpreters/InterpreterSelectQuery.cpp:759: 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 @ 0x0000000014947738 6. /build/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) @ 0x0000000014943f47 7. /build/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) @ 0x000000001494088c 8. /build/src/Interpreters/InterpreterSelectQuery.cpp:303: DB::InterpreterSelectQuery::InterpreterSelectQuery(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x00000000149405d1 9. /build/src/Interpreters/InterpreterExplainQuery.cpp:81: DB::InDepthNodeVisitor>::doVisit(std::shared_ptr&) @ 0x0000000014921cbb 10. /build/src/Interpreters/InDepthNodeVisitor.h:61: void DB::InDepthNodeVisitor>::visitChildren(std::shared_ptr&) @ 0x0000000014921f50 11. /build/src/Interpreters/InDepthNodeVisitor.h:64: void DB::InDepthNodeVisitor>::visitChildren(std::shared_ptr&) @ 0x0000000014921f5b 12. /build/src/Interpreters/InDepthNodeVisitor.h:64: void DB::InDepthNodeVisitor>::visitChildren(std::shared_ptr&) @ 0x0000000014921f5b 13. /build/src/Interpreters/InDepthNodeVisitor.h:64: DB::InterpreterExplainQuery::executeImpl() @ 0x000000001491b83b 14. /build/src/Interpreters/InterpreterExplainQuery.cpp:130: DB::InterpreterExplainQuery::execute() @ 0x0000000014919fc7 15. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88dc9 16. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 17. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 18. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 19. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 20. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 21. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 22. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 23. ? @ 0x00007fbc6213eac3 24. ? @ 0x00007fbc621d0850 2025.07.28 12:02:21.136876 [ 62058 ] {} TCPHandler: Code: 403. DB::Exception: Cannot get JOIN keys from JOIN ON section: 'vx.c0', found keys: [Left keys: [] Right keys [] Condition columns: '', 'vx.c0']: While processing SELECT 1 FROM (SELECT 1 AS c0) AS v0 ALL INNER JOIN v0 AS vx ON vx.c0. (INVALID_JOIN_ON_EXPRESSION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000a06a8eb 4. /build/src/Interpreters/TreeRewriter.cpp:724: DB::TreeRewriter::analyzeSelect(std::shared_ptr&, DB::TreeRewriterResult&&, DB::SelectQueryOptions const&, std::vector> const&, std::vector> const&, std::shared_ptr) const @ 0x0000000014c07505 5. /build/src/Interpreters/InterpreterSelectQuery.cpp:759: 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 @ 0x0000000014947738 6. /build/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) @ 0x0000000014943f47 7. /build/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) @ 0x000000001494088c 8. /build/src/Interpreters/InterpreterSelectQuery.cpp:303: DB::InterpreterSelectQuery::InterpreterSelectQuery(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x00000000149405d1 9. /build/src/Interpreters/InterpreterExplainQuery.cpp:81: DB::InDepthNodeVisitor>::doVisit(std::shared_ptr&) @ 0x0000000014921cbb 10. /build/src/Interpreters/InDepthNodeVisitor.h:61: void DB::InDepthNodeVisitor>::visitChildren(std::shared_ptr&) @ 0x0000000014921f50 11. /build/src/Interpreters/InDepthNodeVisitor.h:64: void DB::InDepthNodeVisitor>::visitChildren(std::shared_ptr&) @ 0x0000000014921f5b 12. /build/src/Interpreters/InDepthNodeVisitor.h:64: void DB::InDepthNodeVisitor>::visitChildren(std::shared_ptr&) @ 0x0000000014921f5b 13. /build/src/Interpreters/InDepthNodeVisitor.h:64: DB::InterpreterExplainQuery::executeImpl() @ 0x000000001491b83b 14. /build/src/Interpreters/InterpreterExplainQuery.cpp:130: DB::InterpreterExplainQuery::execute() @ 0x0000000014919fc7 15. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88dc9 16. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 17. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 18. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 19. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 20. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 21. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 22. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 23. ? @ 0x00007fbc6213eac3 24. ? @ 0x00007fbc621d0850 2025.07.28 12:02:21.196068 [ 62065 ] {} TCPHandler: Code: 394. DB::Exception: Query was cancelled. (QUERY_WAS_CANCELLED), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000000a074fcb 4. /build/src/Interpreters/ProcessList.cpp:567: DB::QueryStatus::throwQueryWasCancelled() const @ 0x0000000014a4bc85 5. /build/src/Interpreters/ProcessList.cpp:520: DB::QueryStatus::throwProperExceptionIfNeeded(unsigned long const&, unsigned long const&) @ 0x0000000014a4bbd9 6. /build/src/Interpreters/ProcessList.cpp:531: DB::QueryStatus::addPipelineExecutor(DB::PipelineExecutor*) @ 0x0000000014a4bd9c 7. /build/src/Processors/Executors/PipelineExecutor.cpp:73: DB::PipelineExecutor::PipelineExecutor(std::shared_ptr, std::allocator>>>&, std::shared_ptr) @ 0x00000000169afe31 8. /build/contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x00000000169c07b5 9. /build/src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x00000000169c0978 10. /build/src/Interpreters/InterpreterKillQueryQuery.cpp:439: DB::InterpreterKillQueryQuery::getSelectResult(String const&, String const&) @ 0x0000000014cf0f04 11. /build/src/Interpreters/InterpreterKillQueryQuery.cpp:222: DB::InterpreterKillQueryQuery::execute() @ 0x0000000014cebde2 12. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88dc9 13. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 14. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 15. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 16. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 17. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 18. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 19. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 20. ? @ 0x00007fbc6213eac3 21. ? @ 0x00007fbc621d0850 2025.07.28 12:02:21.200044 [ 7625 ] {} TCPHandler: Code: 394. DB::Exception: Query was cancelled. (QUERY_WAS_CANCELLED), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000000a074fcb 4. /build/src/Interpreters/ProcessList.cpp:567: DB::QueryStatus::throwQueryWasCancelled() const @ 0x0000000014a4bc85 5. /build/src/Interpreters/ProcessList.cpp:520: DB::QueryStatus::throwProperExceptionIfNeeded(unsigned long const&, unsigned long const&) @ 0x0000000014a4bbd9 6. /build/src/Interpreters/ProcessList.cpp:531: DB::QueryStatus::addPipelineExecutor(DB::PipelineExecutor*) @ 0x0000000014a4bd9c 7. /build/src/Processors/Executors/PipelineExecutor.cpp:73: DB::PipelineExecutor::PipelineExecutor(std::shared_ptr, std::allocator>>>&, std::shared_ptr) @ 0x00000000169afe31 8. /build/contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x00000000169c07b5 9. /build/src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x00000000169c0978 10. /build/src/Interpreters/InterpreterKillQueryQuery.cpp:439: DB::InterpreterKillQueryQuery::getSelectResult(String const&, String const&) @ 0x0000000014cf0f04 11. /build/src/Interpreters/InterpreterKillQueryQuery.cpp:222: DB::InterpreterKillQueryQuery::execute() @ 0x0000000014cebde2 12. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88dc9 13. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 14. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 15. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 16. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 17. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 18. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 19. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 20. ? @ 0x00007fbc6213eac3 21. ? @ 0x00007fbc621d0850 2025.07.28 12:02:21.270930 [ 62075 ] {e8f28f16-da01-4df0-97f6-2608d6f96a50} executeQuery: Code: 394. DB::Exception: Query was cancelled. (QUERY_WAS_CANCELLED) (version 25.3.6.10636.altinitytest (altinity build)) (from [::1]:45862) (comment: 02461_cancel_finish_race.sh) (query 1, line 1) (in query: KILL QUERY WHERE current_database = 'test_dtwle8fg' SYNC FORMAT Null), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000000a074fcb 4. /build/src/Interpreters/ProcessList.cpp:567: DB::QueryStatus::throwQueryWasCancelled() const @ 0x0000000014a4bc85 5. /build/src/Interpreters/ProcessList.cpp:520: DB::QueryStatus::throwProperExceptionIfNeeded(unsigned long const&, unsigned long const&) @ 0x0000000014a4bbd9 6. /build/src/Interpreters/ProcessList.cpp:557: DB::QueryStatus::checkTimeLimit() @ 0x0000000014a4c2cd 7. /build/src/Processors/Executors/PipelineExecutor.cpp:206: DB::PipelineExecutor::finalizeExecution() @ 0x00000000169b13ba 8. /build/src/Processors/Executors/PipelineExecutor.cpp:153: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x00000000169b0584 9. /build/src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:se190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169bfeab 10. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc3d92 11. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fcca080 12. ? @ 0x00007fbc6213eac3 13. ? @ 0x00007fbc621d0850 2025.07.28 12:02:21.288988 [ 62075 ] {} TCPHandler: Code: 394. DB::Exception: Query was cancelled. (QUERY_WAS_CANCELLED), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000000a074fcb 4. /build/src/Interpreters/ProcessList.cpp:567: DB::QueryStatus::throwQueryWasCancelled() const @ 0x0000000014a4bc85 5. /build/src/Interpreters/ProcessList.cpp:520: DB::QueryStatus::throwProperExceptionIfNeeded(unsigned long const&, unsigned long const&) @ 0x0000000014a4bbd9 6. /build/src/Interpreters/ProcessList.cpp:557: DB::QueryStatus::checkTimeLimit() @ 0x0000000014a4c2cd 7. /build/src/Processors/Executors/PipelineExecutor.cpp:206: DB::PipelineExecutor::finalizeExecution() @ 0x00000000169b13ba 8. /build/src/Processors/Executors/PipelineExecutor.cpp:153: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x00000000169b0584 9. /build/src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:se190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169bfeab 10. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc3d92 11. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fcca080 12. ? @ 0x00007fbc6213eac3 13. ? @ 0x00007fbc621d0850 Job's origin stack trace: 0. /build/src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000000fc33b84 1. /build/src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000000fcc2ea7 2. /build/src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fcc535c 3. /build/src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000000fcc584d 4. /build/src/Common/ThreadPool.h:279: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x00000000169bf193 5. /build/src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x00000000169bf518 6. /build/src/Server/TCPHandler.cpp:1237: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x00000000168f1525 7. /build/src/Server/TCPHandler.cpp:678: DB::TCPHandler::runImpl() @ 0x00000000168e68e5 8. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 9. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 10. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 11. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 12. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 13. ? @ 0x00007fbc6213eac3 14. ? @ 0x00007fbc621d0850 2025.07.28 12:02:21.294496 [ 62314 ] {} TCPHandler: Code: 394. DB::Exception: Query 'ee205190-6b36-4824-a861-942d0a25f9ea' is killed in pending state. (QUERY_WAS_CANCELLED), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x000000000a06b56b 4. /build/src/Interpreters/executeQuery.cpp:1522: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c8a4ef 5. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 6. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 7. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 8. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 9. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 10. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 11. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 12. ? @ 0x00007fbc6213eac3 13. ? @ 0x00007fbc621d0850 2025.07.28 12:02:21.318152 [ 17203 ] {9ed4cd4a-fd51-44c9-af3c-110a9c90fc0a} executeQuery: Code: 394. DB::Exception: Query was cancelled. (QUERY_WAS_CANCELLED) (version 25.3.6.10636.altinitytest (altinity build)) (from [::1]:45930) (comment: 02461_cancel_finish_race.sh) (query 1, line 1) (in query: KILL QUERY WHERE current_database = 'test_dtwle8fg' SYNC FORMAT Null), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000000a074fcb 4. /build/src/Interpreters/ProcessList.cpp:567: DB::QueryStatus::throwQueryWasCancelled() const @ 0x0000000014a4bc85 5. /build/src/Interpreters/ProcessList.cpp:520: DB::QueryStatus::throwProperExceptionIfNeeded(unsigned long const&, unsigned long const&) @ 0x0000000014a4bbd9 6. /build/src/Interpreters/ProcessList.cpp:557: DB::QueryStatus::checkTimeLimit() @ 0x0000000014a4c2cd 7. /build/src/Processors/Executors/PipelineExecutor.cpp:206: DB::PipelineExecutor::finalizeExecution() @ 0x00000000169b13ba 8. /build/src/Processors/Executors/PipelineExecutor.cpp:153: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x00000000169b0584 9. /build/src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:se190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169bfeab 10. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc3d92 11. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fcca080 12. ? @ 0x00007fbc6213eac3 13. ? @ 0x00007fbc621d0850 2025.07.28 12:02:21.335015 [ 17203 ] {} TCPHandler: Code: 394. DB::Exception: Query was cancelled. (QUERY_WAS_CANCELLED), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000000a074fcb 4. /build/src/Interpreters/ProcessList.cpp:567: DB::QueryStatus::throwQueryWasCancelled() const @ 0x0000000014a4bc85 5. /build/src/Interpreters/ProcessList.cpp:520: DB::QueryStatus::throwProperExceptionIfNeeded(unsigned long const&, unsigned long const&) @ 0x0000000014a4bbd9 6. /build/src/Interpreters/ProcessList.cpp:557: DB::QueryStatus::checkTimeLimit() @ 0x0000000014a4c2cd 7. /build/src/Processors/Executors/PipelineExecutor.cpp:206: DB::PipelineExecutor::finalizeExecution() @ 0x00000000169b13ba 8. /build/src/Processors/Executors/PipelineExecutor.cpp:153: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x00000000169b0584 9. /build/src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:se190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169bfeab 10. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc3d92 11. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fcca080 12. ? @ 0x00007fbc6213eac3 13. ? @ 0x00007fbc621d0850 Job's origin stack trace: 0. /build/src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000000fc33b84 1. /build/src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000000fcc2ea7 2. /build/src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fcc535c 3. /build/src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000000fcc584d 4. /build/src/Common/ThreadPool.h:279: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x00000000169bf193 5. /build/src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x00000000169bf518 6. /build/src/Server/TCPHandler.cpp:1237: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x00000000168f1525 7. /build/src/Server/TCPHandler.cpp:678: DB::TCPHandler::runImpl() @ 0x00000000168e68e5 8. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 9. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 10. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 11. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 12. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 13. ? @ 0x00007fbc6213eac3 14. ? @ 0x00007fbc621d0850 2025.07.28 12:02:21.483775 [ 5951 ] {cdae4f09-c7a7-43a7-a1ba-a01098f05bd2} executeQuery: Code: 394. DB::Exception: Query was cancelled. (QUERY_WAS_CANCELLED) (version 25.3.6.10636.altinitytest (altinity build)) (from [::1]:45988) (comment: 02461_cancel_finish_race.sh) (query 1, line 1) (in query: KILL QUERY WHERE current_database = 'test_dtwle8fg' SYNC FORMAT Null), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000000a074fcb 4. /build/src/Interpreters/ProcessList.cpp:567: DB::QueryStatus::throwQueryWasCancelled() const @ 0x0000000014a4bc85 5. /build/src/Interpreters/ProcessList.cpp:520: DB::QueryStatus::throwProperExceptionIfNeeded(unsigned long const&, unsigned long const&) @ 0x0000000014a4bbd9 6. /build/src/Interpreters/ProcessList.cpp:557: DB::QueryStatus::checkTimeLimit() @ 0x0000000014a4c2cd 7. /build/src/Processors/Executors/PipelineExecutor.cpp:206: DB::PipelineExecutor::finalizeExecution() @ 0x00000000169b13ba 8. /build/src/Processors/Executors/PipelineExecutor.cpp:153: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x00000000169b0584 9. /build/src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:se190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169bfeab 10. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc3d92 11. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fcca080 12. ? @ 0x00007fbc6213eac3 13. ? @ 0x00007fbc621d0850 2025.07.28 12:02:21.498680 [ 5951 ] {} TCPHandler: Code: 394. DB::Exception: Query was cancelled. (QUERY_WAS_CANCELLED), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000000a074fcb 4. /build/src/Interpreters/ProcessList.cpp:567: DB::QueryStatus::throwQueryWasCancelled() const @ 0x0000000014a4bc85 5. /build/src/Interpreters/ProcessList.cpp:520: DB::QueryStatus::throwProperExceptionIfNeeded(unsigned long const&, unsigned long const&) @ 0x0000000014a4bbd9 6. /build/src/Interpreters/ProcessList.cpp:557: DB::QueryStatus::checkTimeLimit() @ 0x0000000014a4c2cd 7. /build/src/Processors/Executors/PipelineExecutor.cpp:206: DB::PipelineExecutor::finalizeExecution() @ 0x00000000169b13ba 8. /build/src/Processors/Executors/PipelineExecutor.cpp:153: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x00000000169b0584 9. /build/src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:se190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169bfeab 10. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc3d92 11. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fcca080 12. ? @ 0x00007fbc6213eac3 13. ? @ 0x00007fbc621d0850 Job's origin stack trace: 0. /build/src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000000fc33b84 1. /build/src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000000fcc2ea7 2. /build/src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fcc535c 3. /build/src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000000fcc584d 4. /build/src/Common/ThreadPool.h:279: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x00000000169bf193 5. /build/src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x00000000169bf518 6. /build/src/Server/TCPHandler.cpp:1237: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x00000000168f1525 7. /build/src/Server/TCPHandler.cpp:678: DB::TCPHandler::runImpl() @ 0x00000000168e68e5 8. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 9. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 10. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 11. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 12. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 13. ? @ 0x00007fbc6213eac3 14. ? @ 0x00007fbc621d0850 2025.07.28 12:02:21.564847 [ 5112 ] {9abf71ab-8d65-4314-a53e-f0d8e8bad692} executeQuery: Code: 394. DB::Exception: Query was cancelled. (QUERY_WAS_CANCELLED) (version 25.3.6.10636.altinitytest (altinity build)) (from [::1]:46030) (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. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000000a074fcb 4. /build/src/Interpreters/ProcessList.cpp:567: DB::QueryStatus::throwQueryWasCancelled() const @ 0x0000000014a4bc85 5. /build/src/Interpreters/ProcessList.cpp:520: DB::QueryStatus::throwProperExceptionIfNeeded(unsigned long const&, unsigned long const&) @ 0x0000000014a4bbd9 6. /build/src/Interpreters/ProcessList.cpp:531: DB::QueryStatus::addPipelineExecutor(DB::PipelineExecutor*) @ 0x0000000014a4bd9c 7. /build/src/Processors/Executors/PipelineExecutor.cpp:73: DB::PipelineExecutor::PipelineExecutor(std::shared_ptr, std::allocator>>>&, std::shared_ptr) @ 0x00000000169afe31 8. /build/contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x00000000169bef66 9. /build/src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x00000000169bf518 10. /build/src/Server/TCPHandler.cpp:1237: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x00000000168f1525 11. /build/src/Server/TCPHandler.cpp:678: DB::TCPHandler::runImpl() @ 0x00000000168e68e5 12. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 13. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 14. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 16. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 17. ? @ 0x00007fbc6213eac3 18. ? @ 0x00007fbc621d0850 2025.07.28 12:02:21.567825 [ 62053 ] {4db209b6-f14f-46e3-81a4-6967080dd0da} executeQuery: Code: 394. DB::Exception: Query was cancelled. (QUERY_WAS_CANCELLED) (version 25.3.6.10636.altinitytest (altinity build)) (from [::1]:46014) (comment: 02461_cancel_finish_race.sh) (query 1, line 1) (in query: KILL QUERY WHERE current_database = 'test_dtwle8fg' SYNC FORMAT Null), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000000a074fcb 4. /build/src/Interpreters/ProcessList.cpp:567: DB::QueryStatus::throwQueryWasCancelled() const @ 0x0000000014a4bc85 5. /build/src/Interpreters/ProcessList.cpp:520: DB::QueryStatus::throwProperExceptionIfNeeded(unsigned long const&, unsigned long const&) @ 0x0000000014a4bbd9 6. /build/src/Interpreters/ProcessList.cpp:557: DB::QueryStatus::checkTimeLimit() @ 0x0000000014a4c2cd 7. /build/src/Processors/Executors/PipelineExecutor.cpp:206: DB::PipelineExecutor::finalizeExecution() @ 0x00000000169b13ba 8. /build/src/Processors/Executors/PipelineExecutor.cpp:153: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x00000000169b0584 9. /build/src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:se190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169bfeab 10. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc3d92 11. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fcca080 12. ? @ 0x00007fbc6213eac3 13. ? @ 0x00007fbc621d0850 2025.07.28 12:02:21.580628 [ 62053 ] {} TCPHandler: Code: 394. DB::Exception: Query was cancelled. (QUERY_WAS_CANCELLED), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000000a074fcb 4. /build/src/Interpreters/ProcessList.cpp:567: DB::QueryStatus::throwQueryWasCancelled() const @ 0x0000000014a4bc85 5. /build/src/Interpreters/ProcessList.cpp:520: DB::QueryStatus::throwProperExceptionIfNeeded(unsigned long const&, unsigned long const&) @ 0x0000000014a4bbd9 6. /build/src/Interpreters/ProcessList.cpp:557: DB::QueryStatus::checkTimeLimit() @ 0x0000000014a4c2cd 7. /build/src/Processors/Executors/PipelineExecutor.cpp:206: DB::PipelineExecutor::finalizeExecution() @ 0x00000000169b13ba 8. /build/src/Processors/Executors/PipelineExecutor.cpp:153: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x00000000169b0584 9. /build/src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:se190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169bfeab 10. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc3d92 11. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fcca080 12. ? @ 0x00007fbc6213eac3 13. ? @ 0x00007fbc621d0850 Job's origin stack trace: 0. /build/src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000000fc33b84 1. /build/src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000000fcc2ea7 2. /build/src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fcc535c 3. /build/src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000000fcc584d 4. /build/src/Common/ThreadPool.h:279: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x00000000169bf193 5. /build/src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x00000000169bf518 6. /build/src/Server/TCPHandler.cpp:1237: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x00000000168f1525 7. /build/src/Server/TCPHandler.cpp:678: DB::TCPHandler::runImpl() @ 0x00000000168e68e5 8. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 9. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 10. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 11. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 12. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 13. ? @ 0x00007fbc6213eac3 14. ? @ 0x00007fbc621d0850 2025.07.28 12:02:21.637729 [ 5112 ] {} TCPHandler: Code: 394. DB::Exception: Query was cancelled. (QUERY_WAS_CANCELLED), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000000a074fcb 4. /build/src/Interpreters/ProcessList.cpp:567: DB::QueryStatus::throwQueryWasCancelled() const @ 0x0000000014a4bc85 5. /build/src/Interpreters/ProcessList.cpp:520: DB::QueryStatus::throwProperExceptionIfNeeded(unsigned long const&, unsigned long const&) @ 0x0000000014a4bbd9 6. /build/src/Interpreters/ProcessList.cpp:531: DB::QueryStatus::addPipelineExecutor(DB::PipelineExecutor*) @ 0x0000000014a4bd9c 7. /build/src/Processors/Executors/PipelineExecutor.cpp:73: DB::PipelineExecutor::PipelineExecutor(std::shared_ptr, std::allocator>>>&, std::shared_ptr) @ 0x00000000169afe31 8. /build/contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x00000000169bef66 9. /build/src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x00000000169bf518 10. /build/src/Server/TCPHandler.cpp:1237: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x00000000168f1525 11. /build/src/Server/TCPHandler.cpp:678: DB::TCPHandler::runImpl() @ 0x00000000168e68e5 12. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 13. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 14. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 16. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 17. ? @ 0x00007fbc6213eac3 18. ? @ 0x00007fbc621d0850 2025.07.28 12:02:21.652458 [ 62093 ] {} TCPHandler: Code: 394. DB::Exception: Query was cancelled. (QUERY_WAS_CANCELLED), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000000a074fcb 4. /build/src/Interpreters/ProcessList.cpp:567: DB::QueryStatus::throwQueryWasCancelled() const @ 0x0000000014a4bc85 5. /build/src/Interpreters/ProcessList.cpp:520: DB::QueryStatus::throwProperExceptionIfNeeded(unsigned long const&, unsigned long const&) @ 0x0000000014a4bbd9 6. /build/src/Interpreters/ProcessList.cpp:531: DB::QueryStatus::addPipelineExecutor(DB::PipelineExecutor*) @ 0x0000000014a4bd9c 7. /build/src/Processors/Executors/PipelineExecutor.cpp:73: DB::PipelineExecutor::PipelineExecutor(std::shared_ptr, std::allocator>>>&, std::shared_ptr) @ 0x00000000169afe31 8. /build/contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x00000000169c07b5 9. /build/src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x00000000169c0978 10. /build/src/Interpreters/InterpreterKillQueryQuery.cpp:439: DB::InterpreterKillQueryQuery::getSelectResult(String const&, String const&) @ 0x0000000014cf0f04 11. /build/src/Interpreters/InterpreterKillQueryQuery.cpp:222: DB::InterpreterKillQueryQuery::execute() @ 0x0000000014cebde2 12. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88dc9 13. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 14. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 15. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 16. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 17. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 18. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 19. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 20. ? @ 0x00007fbc6213eac3 21. ? @ 0x00007fbc621d0850 2025.07.28 12:02:21.792548 [ 17243 ] {45a86738-bdaf-4c4a-bb07-46c5e1f7f775} executeQuery: Code: 394. DB::Exception: Query was cancelled. (QUERY_WAS_CANCELLED) (version 25.3.6.10636.altinitytest (altinity build)) (from [::1]:33148) (comment: 02461_cancel_finish_race.sh) (query 1, line 1) (in query: KILL QUERY WHERE current_database = 'test_dtwle8fg' SYNC FORMAT Null), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000000a074fcb 4. /build/src/Interpreters/ProcessList.cpp:567: DB::QueryStatus::throwQueryWasCancelled() const @ 0x0000000014a4bc85 5. /build/src/Interpreters/ProcessList.cpp:520: DB::QueryStatus::throwProperExceptionIfNeeded(unsigned long const&, unsigned long const&) @ 0x0000000014a4bbd9 6. /build/src/Interpreters/ProcessList.cpp:557: DB::QueryStatus::checkTimeLimit() @ 0x0000000014a4c2cd 7. /build/src/Processors/Executors/PipelineExecutor.cpp:206: DB::PipelineExecutor::finalizeExecution() @ 0x00000000169b13ba 8. /build/src/Processors/Executors/PipelineExecutor.cpp:153: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x00000000169b0584 9. /build/src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:se190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169bfeab 10. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc3d92 11. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fcca080 12. ? @ 0x00007fbc6213eac3 13. ? @ 0x00007fbc621d0850 2025.07.28 12:02:21.796976 [ 17243 ] {} TCPHandler: Code: 394. DB::Exception: Query was cancelled. (QUERY_WAS_CANCELLED), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000000a074fcb 4. /build/src/Interpreters/ProcessList.cpp:567: DB::QueryStatus::throwQueryWasCancelled() const @ 0x0000000014a4bc85 5. /build/src/Interpreters/ProcessList.cpp:520: DB::QueryStatus::throwProperExceptionIfNeeded(unsigned long const&, unsigned long const&) @ 0x0000000014a4bbd9 6. /build/src/Interpreters/ProcessList.cpp:557: DB::QueryStatus::checkTimeLimit() @ 0x0000000014a4c2cd 7. /build/src/Processors/Executors/PipelineExecutor.cpp:206: DB::PipelineExecutor::finalizeExecution() @ 0x00000000169b13ba 8. /build/src/Processors/Executors/PipelineExecutor.cpp:153: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x00000000169b0584 9. /build/src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:se190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169bfeab 10. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc3d92 11. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fcca080 12. ? @ 0x00007fbc6213eac3 13. ? @ 0x00007fbc621d0850 Job's origin stack trace: 0. /build/src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000000fc33b84 1. /build/src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000000fcc2ea7 2. /build/src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fcc535c 3. /build/src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000000fcc584d 4. /build/src/Common/ThreadPool.h:279: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x00000000169bf193 5. /build/src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x00000000169bf518 6. /build/src/Server/TCPHandler.cpp:1237: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x00000000168f1525 7. /build/src/Server/TCPHandler.cpp:678: DB::TCPHandler::runImpl() @ 0x00000000168e68e5 8. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 9. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 10. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 11. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 12. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 13. ? @ 0x00007fbc6213eac3 14. ? @ 0x00007fbc621d0850 2025.07.28 12:02:21.803091 [ 4900 ] {} TCPHandler: Code: 394. DB::Exception: Query 'edffe259-bfab-4658-9ae4-e442e1782bf7' is killed in pending state. (QUERY_WAS_CANCELLED), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x000000000a06b56b 4. /build/src/Interpreters/executeQuery.cpp:1522: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c8a4ef 5. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 6. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 7. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 8. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 9. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 10. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 11. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 12. ? @ 0x00007fbc6213eac3 13. ? @ 0x00007fbc621d0850 2025.07.28 12:02:21.858870 [ 3970 ] {} test_13.rmt2 (7f9b740d-015c-470e-8cc6-8ba33be0dc63): auto DB::StorageReplicatedMergeTree::processQueueEntry(ReplicatedMergeTreeQueue::SelectedEntryPtr)::(anonymous class)::operator()(LogEntryPtr &) const: Code: 86. DB::HTTPException: Received error from remote server http://146b4357c08d:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Ftest%2F01165%2Ftest_13%2Frmt%2Freplicas%2F1&part=20250728_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.6.10636.altinitytest (altinity build)) '. (RECEIVED_ERROR_FROM_REMOTE_IO_SERVER), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.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 const&, int&&, String const&, unsigned long&&, String const&) @ 0x000000000feda8d9 4. /build/src/IO/HTTPCommon.cpp:104: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x000000000feda6e2 5. /build/src/IO/HTTPCommon.cpp:93: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x000000000feda537 6. /build/src/IO/ReadWriteBufferFromHTTP.cpp:277: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x000000001184a4c4 7. /build/src/IO/ReadWriteBufferFromHTTP.cpp:285: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x000000001184a615 8. /build/src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x000000001184ae59 9. /build/src/IO/ReadWriteBufferFromHTTP.cpp:472: void std::__function::__policy_invoker::__call_impl[abi:se190107]>(std::__function::__policy_storage const*) @ 0x000000001184cedd 10. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001184858b 11. /build/src/IO/ReadWriteBufferFromHTTP.cpp:465: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x000000001184bf0b 12. /build/src/IO/ReadBuffer.h:60: DB::ReadBuffer::next() @ 0x000000000a148c7b 13. /build/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) @ 0x0000000011849fb2 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]>&)>&, 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&) @ 0x0000000011841980 15. /build/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) @ 0x000000001621208e 16. /build/src/Storages/StorageReplicatedMergeTree.cpp:5228: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl[abi:se190107] const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000015f9a5fe 17. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000015ed8bfd 18. /build/src/Storages/StorageReplicatedMergeTree.cpp:2514: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x0000000015ec9aab 19. /build/src/Storages/StorageReplicatedMergeTree.cpp:2349: DB::StorageReplicatedMergeTree::executeLogEntry(DB::ReplicatedMergeTreeLogEntry&) @ 0x0000000015eba91b 20. /build/src/Storages/StorageReplicatedMergeTree.cpp:3876: bool std::__function::__policy_invoker&)>::__call_impl[abi:se190107])::$_1, bool (std::shared_ptr&)>>(std::__function::__policy_storage const*, std::shared_ptr&) @ 0x0000000015f9837e 21. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000165d6fc3 22. /build/src/Storages/StorageReplicatedMergeTree.cpp:3872: DB::StorageReplicatedMergeTree::processQueueEntry(std::shared_ptr) @ 0x0000000015efc18a 23. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001624c1b2 24. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000162f9c70 25. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x00000000162fa55a 26. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc6653 27. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000000fccc4c3 28. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc3d92 29. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fcca080 30. ? @ 0x00007fbc6213eac3 31. ? @ 0x00007fbc621d0850 (version 25.3.6.10636.altinitytest (altinity build)) 2025.07.28 12:02:21.916202 [ 62075 ] {} TCPHandler: Code: 394. DB::Exception: Query was cancelled. (QUERY_WAS_CANCELLED), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000000a074fcb 4. /build/src/Interpreters/ProcessList.cpp:567: DB::QueryStatus::throwQueryWasCancelled() const @ 0x0000000014a4bc85 5. /build/src/Interpreters/ProcessList.cpp:520: DB::QueryStatus::throwProperExceptionIfNeeded(unsigned long const&, unsigned long const&) @ 0x0000000014a4bbd9 6. /build/src/Interpreters/ProcessList.cpp:557: DB::QueryStatus::checkTimeLimit() @ 0x0000000014a4c2cd 7. /build/src/Processors/Executors/PipelineExecutor.cpp:206: DB::PipelineExecutor::finalizeExecution() @ 0x00000000169b13ba 8. /build/src/Processors/Executors/PipelineExecutor.cpp:181: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x00000000169b1726 9. /build/src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x00000000169c081c 10. /build/src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x00000000169c0978 11. /build/src/Interpreters/InterpreterKillQueryQuery.cpp:442: DB::InterpreterKillQueryQuery::getSelectResult(String const&, String const&) @ 0x0000000014cf0f6b 12. /build/src/Interpreters/InterpreterKillQueryQuery.cpp:222: DB::InterpreterKillQueryQuery::execute() @ 0x0000000014cebde2 13. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88dc9 14. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 15. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 16. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 17. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 18. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 19. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 20. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 21. ? @ 0x00007fbc6213eac3 22. ? @ 0x00007fbc621d0850 2025.07.28 12:02:21.921846 [ 62325 ] {} TCPHandler: Code: 394. DB::Exception: Query was cancelled. (QUERY_WAS_CANCELLED), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000000a074fcb 4. /build/src/Interpreters/ProcessList.cpp:567: DB::QueryStatus::throwQueryWasCancelled() const @ 0x0000000014a4bc85 5. /build/src/Interpreters/ProcessList.cpp:520: DB::QueryStatus::throwProperExceptionIfNeeded(unsigned long const&, unsigned long const&) @ 0x0000000014a4bbd9 6. /build/src/Interpreters/ProcessList.cpp:531: DB::QueryStatus::addPipelineExecutor(DB::PipelineExecutor*) @ 0x0000000014a4bd9c 7. /build/src/Processors/Executors/PipelineExecutor.cpp:73: DB::PipelineExecutor::PipelineExecutor(std::shared_ptr, std::allocator>>>&, std::shared_ptr) @ 0x00000000169afe31 8. /build/contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x00000000169c07b5 9. /build/src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x00000000169c0978 10. /build/src/Interpreters/InterpreterKillQueryQuery.cpp:439: DB::InterpreterKillQueryQuery::getSelectResult(String const&, String const&) @ 0x0000000014cf0f04 11. /build/src/Interpreters/InterpreterKillQueryQuery.cpp:222: DB::InterpreterKillQueryQuery::execute() @ 0x0000000014cebde2 12. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88dc9 13. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 14. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 15. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 16. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 17. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 18. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 19. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 20. ? @ 0x00007fbc6213eac3 21. ? @ 0x00007fbc621d0850 2025.07.28 12:02:22.043799 [ 4963 ] {d2d78429-f68d-4ab2-9999-1ea4dfecced2} executeQuery: Code: 394. DB::Exception: Query was cancelled. (QUERY_WAS_CANCELLED) (version 25.3.6.10636.altinitytest (altinity build)) (from [::1]:33154) (comment: 02461_cancel_finish_race.sh) (query 1, line 1) (in query: KILL QUERY WHERE current_database = 'test_dtwle8fg' SYNC FORMAT Null), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000000a074fcb 4. /build/src/Interpreters/ProcessList.cpp:567: DB::QueryStatus::throwQueryWasCancelled() const @ 0x0000000014a4bc85 5. /build/src/Interpreters/ProcessList.cpp:520: DB::QueryStatus::throwProperExceptionIfNeeded(unsigned long const&, unsigned long const&) @ 0x0000000014a4bbd9 6. /build/src/Interpreters/ProcessList.cpp:557: DB::QueryStatus::checkTimeLimit() @ 0x0000000014a4c2cd 7. /build/src/Processors/Executors/PipelineExecutor.cpp:206: DB::PipelineExecutor::finalizeExecution() @ 0x00000000169b13ba 8. /build/src/Processors/Executors/PipelineExecutor.cpp:153: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x00000000169b0584 9. /build/src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:se190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169bfeab 10. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc3d92 11. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fcca080 12. ? @ 0x00007fbc6213eac3 13. ? @ 0x00007fbc621d0850 2025.07.28 12:02:22.047434 [ 62055 ] {} TCPHandler: Code: 394. DB::Exception: Query was cancelled. (QUERY_WAS_CANCELLED), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000000a074fcb 4. /build/src/Interpreters/ProcessList.cpp:567: DB::QueryStatus::throwQueryWasCancelled() const @ 0x0000000014a4bc85 5. /build/src/Interpreters/ProcessList.cpp:520: DB::QueryStatus::throwProperExceptionIfNeeded(unsigned long const&, unsigned long const&) @ 0x0000000014a4bbd9 6. /build/src/Interpreters/ProcessList.cpp:531: DB::QueryStatus::addPipelineExecutor(DB::PipelineExecutor*) @ 0x0000000014a4bd9c 7. /build/src/Processors/Executors/PipelineExecutor.cpp:73: DB::PipelineExecutor::PipelineExecutor(std::shared_ptr, std::allocator>>>&, std::shared_ptr) @ 0x00000000169afe31 8. /build/contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x00000000169c07b5 9. /build/src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x00000000169c0978 10. /build/src/Interpreters/InterpreterKillQueryQuery.cpp:439: DB::InterpreterKillQueryQuery::getSelectResult(String const&, String const&) @ 0x0000000014cf0f04 11. /build/src/Interpreters/InterpreterKillQueryQuery.cpp:222: DB::InterpreterKillQueryQuery::execute() @ 0x0000000014cebde2 12. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88dc9 13. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 14. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 15. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 16. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 17. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 18. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 19. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 20. ? @ 0x00007fbc6213eac3 21. ? @ 0x00007fbc621d0850 2025.07.28 12:02:22.128663 [ 4963 ] {} TCPHandler: Code: 394. DB::Exception: Query was cancelled. (QUERY_WAS_CANCELLED), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000000a074fcb 4. /build/src/Interpreters/ProcessList.cpp:567: DB::QueryStatus::throwQueryWasCancelled() const @ 0x0000000014a4bc85 5. /build/src/Interpreters/ProcessList.cpp:520: DB::QueryStatus::throwProperExceptionIfNeeded(unsigned long const&, unsigned long const&) @ 0x0000000014a4bbd9 6. /build/src/Interpreters/ProcessList.cpp:557: DB::QueryStatus::checkTimeLimit() @ 0x0000000014a4c2cd 7. /build/src/Processors/Executors/PipelineExecutor.cpp:206: DB::PipelineExecutor::finalizeExecution() @ 0x00000000169b13ba 8. /build/src/Processors/Executors/PipelineExecutor.cpp:153: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x00000000169b0584 9. /build/src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:se190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169bfeab 10. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc3d92 11. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fcca080 12. ? @ 0x00007fbc6213eac3 13. ? @ 0x00007fbc621d0850 Job's origin stack trace: 0. /build/src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000000fc33b84 1. /build/src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000000fcc2ea7 2. /build/src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fcc535c 3. /build/src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000000fcc584d 4. /build/src/Common/ThreadPool.h:279: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x00000000169bf193 5. /build/src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x00000000169bf518 6. /build/src/Server/TCPHandler.cpp:1237: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x00000000168f1525 7. /build/src/Server/TCPHandler.cpp:678: DB::TCPHandler::runImpl() @ 0x00000000168e68e5 8. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 9. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 10. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 11. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 12. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 13. ? @ 0x00007fbc6213eac3 14. ? @ 0x00007fbc621d0850 2025.07.28 12:02:22.219367 [ 62053 ] {8664db7d-e224-49f6-bd49-624e0566fabc} executeQuery: Code: 394. DB::Exception: Query was cancelled. (QUERY_WAS_CANCELLED) (version 25.3.6.10636.altinitytest (altinity build)) (from [::1]:33220) (comment: 02461_cancel_finish_race.sh) (query 1, line 1) (in query: KILL QUERY WHERE current_database = 'test_dtwle8fg' SYNC FORMAT Null), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000000a074fcb 4. /build/src/Interpreters/ProcessList.cpp:567: DB::QueryStatus::throwQueryWasCancelled() const @ 0x0000000014a4bc85 5. /build/src/Interpreters/ProcessList.cpp:520: DB::QueryStatus::throwProperExceptionIfNeeded(unsigned long const&, unsigned long const&) @ 0x0000000014a4bbd9 6. /build/src/Interpreters/ProcessList.cpp:557: DB::QueryStatus::checkTimeLimit() @ 0x0000000014a4c2cd 7. /build/src/Processors/Executors/PipelineExecutor.cpp:206: DB::PipelineExecutor::finalizeExecution() @ 0x00000000169b13ba 8. /build/src/Processors/Executors/PipelineExecutor.cpp:153: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x00000000169b0584 9. /build/src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:se190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169bfeab 10. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc3d92 11. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fcca080 12. ? @ 0x00007fbc6213eac3 13. ? @ 0x00007fbc621d0850 2025.07.28 12:02:22.232450 [ 11826 ] {47d0421c-cf1c-4ce4-bf14-e1f7363d0b47} executeQuery: Code: 394. DB::Exception: Query was cancelled. (QUERY_WAS_CANCELLED) (version 25.3.6.10636.altinitytest (altinity build)) (from [::1]:33250) (comment: 02461_cancel_finish_race.sh) (query 1, line 1) (in query: KILL QUERY WHERE current_database = 'test_dtwle8fg' SYNC FORMAT Null), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000000a074fcb 4. /build/src/Interpreters/ProcessList.cpp:567: DB::QueryStatus::throwQueryWasCancelled() const @ 0x0000000014a4bc85 5. /build/src/Interpreters/ProcessList.cpp:520: DB::QueryStatus::throwProperExceptionIfNeeded(unsigned long const&, unsigned long const&) @ 0x0000000014a4bbd9 6. /build/src/Interpreters/ProcessList.cpp:557: DB::QueryStatus::checkTimeLimit() @ 0x0000000014a4c2cd 7. /build/src/Processors/Executors/PipelineExecutor.cpp:206: DB::PipelineExecutor::finalizeExecution() @ 0x00000000169b13ba 8. /build/src/Processors/Executors/PipelineExecutor.cpp:153: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x00000000169b0584 9. /build/src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:se190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169bfeab 10. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc3d92 11. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fcca080 12. ? @ 0x00007fbc6213eac3 13. ? @ 0x00007fbc621d0850 2025.07.28 12:02:22.235831 [ 62053 ] {} TCPHandler: Code: 394. DB::Exception: Query was cancelled. (QUERY_WAS_CANCELLED), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000000a074fcb 4. /build/src/Interpreters/ProcessList.cpp:567: DB::QueryStatus::throwQueryWasCancelled() const @ 0x0000000014a4bc85 5. /build/src/Interpreters/ProcessList.cpp:520: DB::QueryStatus::throwProperExceptionIfNeeded(unsigned long const&, unsigned long const&) @ 0x0000000014a4bbd9 6. /build/src/Interpreters/ProcessList.cpp:557: DB::QueryStatus::checkTimeLimit() @ 0x0000000014a4c2cd 7. /build/src/Processors/Executors/PipelineExecutor.cpp:206: DB::PipelineExecutor::finalizeExecution() @ 0x00000000169b13ba 8. /build/src/Processors/Executors/PipelineExecutor.cpp:153: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x00000000169b0584 9. /build/src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:se190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169bfeab 10. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc3d92 11. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fcca080 12. ? @ 0x00007fbc6213eac3 13. ? @ 0x00007fbc621d0850 Job's origin stack trace: 0. /build/src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000000fc33b84 1. /build/src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000000fcc2ea7 2. /build/src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fcc535c 3. /build/src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000000fcc584d 4. /build/src/Common/ThreadPool.h:279: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x00000000169bf193 5. /build/src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x00000000169bf518 6. /build/src/Server/TCPHandler.cpp:1237: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x00000000168f1525 7. /build/src/Server/TCPHandler.cpp:678: DB::TCPHandler::runImpl() @ 0x00000000168e68e5 8. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 9. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 10. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 11. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 12. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 13. ? @ 0x00007fbc6213eac3 14. ? @ 0x00007fbc621d0850 2025.07.28 12:02:22.240542 [ 63425 ] {cee957d2-6d31-4b0a-bf6e-95687c6262c2} executeQuery: Code: 394. DB::Exception: Query was cancelled. (QUERY_WAS_CANCELLED) (version 25.3.6.10636.altinitytest (altinity build)) (from [::1]:33258) (comment: 02461_cancel_finish_race.sh) (query 1, line 1) (in query: KILL QUERY WHERE current_database = 'test_dtwle8fg' SYNC FORMAT Null), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000000a074fcb 4. /build/src/Interpreters/ProcessList.cpp:567: DB::QueryStatus::throwQueryWasCancelled() const @ 0x0000000014a4bc85 5. /build/src/Interpreters/ProcessList.cpp:520: DB::QueryStatus::throwProperExceptionIfNeeded(unsigned long const&, unsigned long const&) @ 0x0000000014a4bbd9 6. /build/src/Interpreters/ProcessList.cpp:557: DB::QueryStatus::checkTimeLimit() @ 0x0000000014a4c2cd 7. /build/src/Processors/Executors/PipelineExecutor.cpp:206: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x00000000169b03a3 8. /build/src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:se190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169bfeab 9. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc3d92 10. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fcca080 11. ? @ 0x00007fbc6213eac3 12. ? @ 0x00007fbc621d0850 2025.07.28 12:02:22.240669 [ 62056 ] {dbe7ff9c-c2ab-45c6-b762-f4c7874f2248} executeQuery: Code: 394. DB::Exception: Query was cancelled. (QUERY_WAS_CANCELLED) (version 25.3.6.10636.altinitytest (altinity build)) (from [::1]:33216) (comment: 02461_cancel_finish_race.sh) (query 1, line 1) (in query: KILL QUERY WHERE current_database = 'test_dtwle8fg' SYNC FORMAT Null), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000000a074fcb 4. /build/src/Interpreters/ProcessList.cpp:567: DB::QueryStatus::throwQueryWasCancelled() const @ 0x0000000014a4bc85 5. /build/src/Interpreters/ProcessList.cpp:520: DB::QueryStatus::throwProperExceptionIfNeeded(unsigned long const&, unsigned long const&) @ 0x0000000014a4bbd9 6. /build/src/Interpreters/ProcessList.cpp:557: DB::QueryStatus::checkTimeLimit() @ 0x0000000014a4c2cd 7. /build/src/Processors/Executors/PipelineExecutor.cpp:206: DB::PipelineExecutor::finalizeExecution() @ 0x00000000169b13ba 8. /build/src/Processors/Executors/PipelineExecutor.cpp:153: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x00000000169b0584 9. /build/src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:se190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169bfeab 10. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc3d92 11. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fcca080 12. ? @ 0x00007fbc6213eac3 13. ? @ 0x00007fbc621d0850 2025.07.28 12:02:22.251652 [ 62056 ] {} TCPHandler: Code: 394. DB::Exception: Query was cancelled. (QUERY_WAS_CANCELLED), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000000a074fcb 4. /build/src/Interpreters/ProcessList.cpp:567: DB::QueryStatus::throwQueryWasCancelled() const @ 0x0000000014a4bc85 5. /build/src/Interpreters/ProcessList.cpp:520: DB::QueryStatus::throwProperExceptionIfNeeded(unsigned long const&, unsigned long const&) @ 0x0000000014a4bbd9 6. /build/src/Interpreters/ProcessList.cpp:557: DB::QueryStatus::checkTimeLimit() @ 0x0000000014a4c2cd 7. /build/src/Processors/Executors/PipelineExecutor.cpp:206: DB::PipelineExecutor::finalizeExecution() @ 0x00000000169b13ba 8. /build/src/Processors/Executors/PipelineExecutor.cpp:153: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x00000000169b0584 9. /build/src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:se190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169bfeab 10. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc3d92 11. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fcca080 12. ? @ 0x00007fbc6213eac3 13. ? @ 0x00007fbc621d0850 Job's origin stack trace: 0. /build/src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000000fc33b84 1. /build/src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000000fcc2ea7 2. /build/src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fcc535c 3. /build/src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000000fcc584d 4. /build/src/Common/ThreadPool.h:279: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x00000000169bf193 5. /build/src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x00000000169bf518 6. /build/src/Server/TCPHandler.cpp:1237: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x00000000168f1525 7. /build/src/Server/TCPHandler.cpp:678: DB::TCPHandler::runImpl() @ 0x00000000168e68e5 8. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 9. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 10. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 11. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 12. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 13. ? @ 0x00007fbc6213eac3 14. ? @ 0x00007fbc621d0850 2025.07.28 12:02:22.255951 [ 11826 ] {} TCPHandler: Code: 394. DB::Exception: Query was cancelled. (QUERY_WAS_CANCELLED), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000000a074fcb 4. /build/src/Interpreters/ProcessList.cpp:567: DB::QueryStatus::throwQueryWasCancelled() const @ 0x0000000014a4bc85 5. /build/src/Interpreters/ProcessList.cpp:520: DB::QueryStatus::throwProperExceptionIfNeeded(unsigned long const&, unsigned long const&) @ 0x0000000014a4bbd9 6. /build/src/Interpreters/ProcessList.cpp:557: DB::QueryStatus::checkTimeLimit() @ 0x0000000014a4c2cd 7. /build/src/Processors/Executors/PipelineExecutor.cpp:206: DB::PipelineExecutor::finalizeExecution() @ 0x00000000169b13ba 8. /build/src/Processors/Executors/PipelineExecutor.cpp:153: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x00000000169b0584 9. /build/src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:se190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169bfeab 10. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc3d92 11. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fcca080 12. ? @ 0x00007fbc6213eac3 13. ? @ 0x00007fbc621d0850 Job's origin stack trace: 0. /build/src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000000fc33b84 1. /build/src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000000fcc2ea7 2. /build/src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fcc535c 3. /build/src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000000fcc584d 4. /build/src/Common/ThreadPool.h:279: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x00000000169bf193 5. /build/src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x00000000169bf518 6. /build/src/Server/TCPHandler.cpp:1237: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x00000000168f1525 7. /build/src/Server/TCPHandler.cpp:678: DB::TCPHandler::runImpl() @ 0x00000000168e68e5 8. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 9. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 10. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 11. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 12. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 13. ? @ 0x00007fbc6213eac3 14. ? @ 0x00007fbc621d0850 2025.07.28 12:02:22.317393 [ 63425 ] {} TCPHandler: Code: 394. DB::Exception: Query was cancelled. (QUERY_WAS_CANCELLED), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000000a074fcb 4. /build/src/Interpreters/ProcessList.cpp:567: DB::QueryStatus::throwQueryWasCancelled() const @ 0x0000000014a4bc85 5. /build/src/Interpreters/ProcessList.cpp:520: DB::QueryStatus::throwProperExceptionIfNeeded(unsigned long const&, unsigned long const&) @ 0x0000000014a4bbd9 6. /build/src/Interpreters/ProcessList.cpp:557: DB::QueryStatus::checkTimeLimit() @ 0x0000000014a4c2cd 7. /build/src/Processors/Executors/PipelineExecutor.cpp:206: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x00000000169b03a3 8. /build/src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:se190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169bfeab 9. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc3d92 10. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fcca080 11. ? @ 0x00007fbc6213eac3 12. ? @ 0x00007fbc621d0850 Job's origin stack trace: 0. /build/src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000000fc33b84 1. /build/src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000000fcc2ea7 2. /build/src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fcc535c 3. /build/src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000000fcc584d 4. /build/src/Common/ThreadPool.h:279: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x00000000169bf193 5. /build/src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x00000000169bf518 6. /build/src/Server/TCPHandler.cpp:1237: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x00000000168f1525 7. /build/src/Server/TCPHandler.cpp:678: DB::TCPHandler::runImpl() @ 0x00000000168e68e5 8. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 9. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 10. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 11. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 12. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 13. ? @ 0x00007fbc6213eac3 14. ? @ 0x00007fbc621d0850 2025.07.28 12:02:22.325253 [ 17611 ] {} TCPHandler: Code: 394. DB::Exception: Query was cancelled. (QUERY_WAS_CANCELLED), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000000a074fcb 4. /build/src/Interpreters/ProcessList.cpp:567: DB::QueryStatus::throwQueryWasCancelled() const @ 0x0000000014a4bc85 5. /build/src/Interpreters/ProcessList.cpp:520: DB::QueryStatus::throwProperExceptionIfNeeded(unsigned long const&, unsigned long const&) @ 0x0000000014a4bbd9 6. /build/src/Interpreters/ProcessList.cpp:557: DB::QueryStatus::checkTimeLimit() @ 0x0000000014a4c2cd 7. /build/src/Processors/Executors/PipelineExecutor.cpp:206: DB::PipelineExecutor::finalizeExecution() @ 0x00000000169b13ba 8. /build/src/Processors/Executors/PipelineExecutor.cpp:181: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x00000000169b1726 9. /build/src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x00000000169c081c 10. /build/src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x00000000169c0978 11. /build/src/Interpreters/InterpreterKillQueryQuery.cpp:439: DB::InterpreterKillQueryQuery::getSelectResult(String const&, String const&) @ 0x0000000014cf0f04 12. /build/src/Interpreters/InterpreterKillQueryQuery.cpp:222: DB::InterpreterKillQueryQuery::execute() @ 0x0000000014cebde2 13. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88dc9 14. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 15. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 16. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 17. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 18. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 19. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 20. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 21. ? @ 0x00007fbc6213eac3 22. ? @ 0x00007fbc621d0850 2025.07.28 12:02:22.331267 [ 3969 ] {} test_13.rmt2 (7f9b740d-015c-470e-8cc6-8ba33be0dc63): auto DB::StorageReplicatedMergeTree::processQueueEntry(ReplicatedMergeTreeQueue::SelectedEntryPtr)::(anonymous class)::operator()(LogEntryPtr &) const: Code: 86. DB::HTTPException: Received error from remote server http://146b4357c08d:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Ftest%2F01165%2Ftest_13%2Frmt%2Freplicas%2F1&part=20250728_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.6.10636.altinitytest (altinity build)) '. (RECEIVED_ERROR_FROM_REMOTE_IO_SERVER), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.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 const&, int&&, String const&, unsigned long&&, String const&) @ 0x000000000feda8d9 4. /build/src/IO/HTTPCommon.cpp:104: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x000000000feda6e2 5. /build/src/IO/HTTPCommon.cpp:93: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x000000000feda537 6. /build/src/IO/ReadWriteBufferFromHTTP.cpp:277: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x000000001184a4c4 7. /build/src/IO/ReadWriteBufferFromHTTP.cpp:285: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x000000001184a615 8. /build/src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x000000001184ae59 9. /build/src/IO/ReadWriteBufferFromHTTP.cpp:472: void std::__function::__policy_invoker::__call_impl[abi:se190107]>(std::__function::__policy_storage const*) @ 0x000000001184cedd 10. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001184858b 11. /build/src/IO/ReadWriteBufferFromHTTP.cpp:465: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x000000001184bf0b 12. /build/src/IO/ReadBuffer.h:60: DB::ReadBuffer::next() @ 0x000000000a148c7b 13. /build/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) @ 0x0000000011849fb2 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]>&)>&, 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&) @ 0x0000000011841980 15. /build/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) @ 0x000000001621208e 16. /build/src/Storages/StorageReplicatedMergeTree.cpp:5228: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl[abi:se190107] const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000015f9a5fe 17. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000015ed8bfd 18. /build/src/Storages/StorageReplicatedMergeTree.cpp:2514: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x0000000015ec9aab 19. /build/src/Storages/StorageReplicatedMergeTree.cpp:2349: DB::StorageReplicatedMergeTree::executeLogEntry(DB::ReplicatedMergeTreeLogEntry&) @ 0x0000000015eba91b 20. /build/src/Storages/StorageReplicatedMergeTree.cpp:3876: bool std::__function::__policy_invoker&)>::__call_impl[abi:se190107])::$_1, bool (std::shared_ptr&)>>(std::__function::__policy_storage const*, std::shared_ptr&) @ 0x0000000015f9837e 21. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000165d6fc3 22. /build/src/Storages/StorageReplicatedMergeTree.cpp:3872: DB::StorageReplicatedMergeTree::processQueueEntry(std::shared_ptr) @ 0x0000000015efc18a 23. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001624c1b2 24. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000162f9c70 25. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x00000000162fa55a 26. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc6653 27. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000000fccc4c3 28. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc3d92 29. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fcca080 30. ? @ 0x00007fbc6213eac3 31. ? @ 0x00007fbc621d0850 (version 25.3.6.10636.altinitytest (altinity build)) 2025.07.28 12:02:22.449492 [ 62314 ] {79a4590e-05df-4fcd-ac1b-8ef6909d99a7} executeQuery: Code: 394. DB::Exception: Query was cancelled. (QUERY_WAS_CANCELLED) (version 25.3.6.10636.altinitytest (altinity build)) (from [::1]:33336) (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. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000000a074fcb 4. /build/src/Interpreters/ProcessList.cpp:567: DB::QueryStatus::throwQueryWasCancelled() const @ 0x0000000014a4bc85 5. /build/src/Interpreters/ProcessList.cpp:520: DB::QueryStatus::throwProperExceptionIfNeeded(unsigned long const&, unsigned long const&) @ 0x0000000014a4bbd9 6. /build/src/Interpreters/ProcessList.cpp:557: DB::QueryStatus::checkTimeLimit() @ 0x0000000014a4c2cd 7. /build/src/Processors/Executors/PipelineExecutor.cpp:206: DB::PipelineExecutor::finalizeExecution() @ 0x00000000169b13ba 8. /build/src/Processors/Executors/PipelineExecutor.cpp:153: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x00000000169b0584 9. /build/src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:se190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169bfeab 10. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc3d92 11. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fcca080 12. ? @ 0x00007fbc6213eac3 13. ? @ 0x00007fbc621d0850 2025.07.28 12:02:22.457950 [ 62057 ] {fff76c73-4872-436c-8286-73e3a82908b4} executeQuery: Code: 394. DB::Exception: Query was cancelled. (QUERY_WAS_CANCELLED) (version 25.3.6.10636.altinitytest (altinity build)) (from [::1]:33318) (comment: 02461_cancel_finish_race.sh) (query 1, line 1) (in query: KILL QUERY WHERE current_database = 'test_dtwle8fg' SYNC FORMAT Null), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000000a074fcb 4. /build/src/Interpreters/ProcessList.cpp:567: DB::QueryStatus::throwQueryWasCancelled() const @ 0x0000000014a4bc85 5. /build/src/Interpreters/ProcessList.cpp:520: DB::QueryStatus::throwProperExceptionIfNeeded(unsigned long const&, unsigned long const&) @ 0x0000000014a4bbd9 6. /build/src/Interpreters/ProcessList.cpp:557: DB::QueryStatus::checkTimeLimit() @ 0x0000000014a4c2cd 7. /build/src/Processors/Executors/PipelineExecutor.cpp:206: DB::PipelineExecutor::finalizeExecution() @ 0x00000000169b13ba 8. /build/src/Processors/Executors/PipelineExecutor.cpp:153: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x00000000169b0584 9. /build/src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:se190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169bfeab 10. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc3d92 11. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fcca080 12. ? @ 0x00007fbc6213eac3 13. ? @ 0x00007fbc621d0850 2025.07.28 12:02:22.462083 [ 5951 ] {9f167b3b-6c5b-487c-897f-5a88d384b055} executeQuery: Code: 394. DB::Exception: Query was cancelled. (QUERY_WAS_CANCELLED) (version 25.3.6.10636.altinitytest (altinity build)) (from [::1]:33344) (comment: 02461_cancel_finish_race.sh) (query 1, line 1) (in query: KILL QUERY WHERE current_database = 'test_dtwle8fg' SYNC FORMAT Null), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000000a074fcb 4. /build/src/Interpreters/ProcessList.cpp:567: DB::QueryStatus::throwQueryWasCancelled() const @ 0x0000000014a4bc85 5. /build/src/Interpreters/ProcessList.cpp:520: DB::QueryStatus::throwProperExceptionIfNeeded(unsigned long const&, unsigned long const&) @ 0x0000000014a4bbd9 6. /build/src/Interpreters/ProcessList.cpp:557: DB::QueryStatus::checkTimeLimit() @ 0x0000000014a4c2cd 7. /build/src/Processors/Executors/PipelineExecutor.cpp:206: DB::PipelineExecutor::finalizeExecution() @ 0x00000000169b13ba 8. /build/src/Processors/Executors/PipelineExecutor.cpp:153: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x00000000169b0584 9. /build/src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:se190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169bfeab 10. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc3d92 11. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fcca080 12. ? @ 0x00007fbc6213eac3 13. ? @ 0x00007fbc621d0850 2025.07.28 12:02:22.462116 [ 62314 ] {} TCPHandler: Code: 394. DB::Exception: Query was cancelled. (QUERY_WAS_CANCELLED), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000000a074fcb 4. /build/src/Interpreters/ProcessList.cpp:567: DB::QueryStatus::throwQueryWasCancelled() const @ 0x0000000014a4bc85 5. /build/src/Interpreters/ProcessList.cpp:520: DB::QueryStatus::throwProperExceptionIfNeeded(unsigned long const&, unsigned long const&) @ 0x0000000014a4bbd9 6. /build/src/Interpreters/ProcessList.cpp:557: DB::QueryStatus::checkTimeLimit() @ 0x0000000014a4c2cd 7. /build/src/Processors/Executors/PipelineExecutor.cpp:206: DB::PipelineExecutor::finalizeExecution() @ 0x00000000169b13ba 8. /build/src/Processors/Executors/PipelineExecutor.cpp:153: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x00000000169b0584 9. /build/src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:se190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169bfeab 10. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc3d92 11. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fcca080 12. ? @ 0x00007fbc6213eac3 13. ? @ 0x00007fbc621d0850 Job's origin stack trace: 0. /build/src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000000fc33b84 1. /build/src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000000fcc2ea7 2. /build/src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fcc535c 3. /build/src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000000fcc584d 4. /build/src/Common/ThreadPool.h:279: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x00000000169bf193 5. /build/src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x00000000169bf518 6. /build/src/Server/TCPHandler.cpp:1237: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x00000000168f1525 7. /build/src/Server/TCPHandler.cpp:678: DB::TCPHandler::runImpl() @ 0x00000000168e68e5 8. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 9. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 10. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 11. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 12. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 13. ? @ 0x00007fbc6213eac3 14. ? @ 0x00007fbc621d0850 2025.07.28 12:02:22.476543 [ 62057 ] {} TCPHandler: Code: 394. DB::Exception: Query was cancelled. (QUERY_WAS_CANCELLED), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000000a074fcb 4. /build/src/Interpreters/ProcessList.cpp:567: DB::QueryStatus::throwQueryWasCancelled() const @ 0x0000000014a4bc85 5. /build/src/Interpreters/ProcessList.cpp:520: DB::QueryStatus::throwProperExceptionIfNeeded(unsigned long const&, unsigned long const&) @ 0x0000000014a4bbd9 6. /build/src/Interpreters/ProcessList.cpp:557: DB::QueryStatus::checkTimeLimit() @ 0x0000000014a4c2cd 7. /build/src/Processors/Executors/PipelineExecutor.cpp:206: DB::PipelineExecutor::finalizeExecution() @ 0x00000000169b13ba 8. /build/src/Processors/Executors/PipelineExecutor.cpp:153: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x00000000169b0584 9. /build/src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:se190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169bfeab 10. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc3d92 11. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fcca080 12. ? @ 0x00007fbc6213eac3 13. ? @ 0x00007fbc621d0850 Job's origin stack trace: 0. /build/src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000000fc33b84 1. /build/src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000000fcc2ea7 2. /build/src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fcc535c 3. /build/src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000000fcc584d 4. /build/src/Common/ThreadPool.h:279: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x00000000169bf193 5. /build/src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x00000000169bf518 6. /build/src/Server/TCPHandler.cpp:1237: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x00000000168f1525 7. /build/src/Server/TCPHandler.cpp:678: DB::TCPHandler::runImpl() @ 0x00000000168e68e5 8. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 9. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 10. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 11. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 12. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 13. ? @ 0x00007fbc6213eac3 14. ? @ 0x00007fbc621d0850 2025.07.28 12:02:22.477358 [ 5951 ] {} TCPHandler: Code: 394. DB::Exception: Query was cancelled. (QUERY_WAS_CANCELLED), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000000a074fcb 4. /build/src/Interpreters/ProcessList.cpp:567: DB::QueryStatus::throwQueryWasCancelled() const @ 0x0000000014a4bc85 5. /build/src/Interpreters/ProcessList.cpp:520: DB::QueryStatus::throwProperExceptionIfNeeded(unsigned long const&, unsigned long const&) @ 0x0000000014a4bbd9 6. /build/src/Interpreters/ProcessList.cpp:557: DB::QueryStatus::checkTimeLimit() @ 0x0000000014a4c2cd 7. /build/src/Processors/Executors/PipelineExecutor.cpp:206: DB::PipelineExecutor::finalizeExecution() @ 0x00000000169b13ba 8. /build/src/Processors/Executors/PipelineExecutor.cpp:153: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x00000000169b0584 9. /build/src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:se190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169bfeab 10. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc3d92 11. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fcca080 12. ? @ 0x00007fbc6213eac3 13. ? @ 0x00007fbc621d0850 Job's origin stack trace: 0. /build/src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000000fc33b84 1. /build/src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000000fcc2ea7 2. /build/src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fcc535c 3. /build/src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000000fcc584d 4. /build/src/Common/ThreadPool.h:279: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x00000000169bf193 5. /build/src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x00000000169bf518 6. /build/src/Server/TCPHandler.cpp:1237: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x00000000168f1525 7. /build/src/Server/TCPHandler.cpp:678: DB::TCPHandler::runImpl() @ 0x00000000168e68e5 8. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 9. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 10. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 11. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 12. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 13. ? @ 0x00007fbc6213eac3 14. ? @ 0x00007fbc621d0850 2025.07.28 12:02:22.555106 [ 17252 ] {} TCPHandler: Code: 394. DB::Exception: Query was cancelled. (QUERY_WAS_CANCELLED), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000000a074fcb 4. /build/src/Interpreters/ProcessList.cpp:567: DB::QueryStatus::throwQueryWasCancelled() const @ 0x0000000014a4bc85 5. /build/src/Interpreters/ProcessList.cpp:520: DB::QueryStatus::throwProperExceptionIfNeeded(unsigned long const&, unsigned long const&) @ 0x0000000014a4bbd9 6. /build/src/Interpreters/ProcessList.cpp:557: DB::QueryStatus::checkTimeLimit() @ 0x0000000014a4c2cd 7. /build/src/Processors/Executors/PipelineExecutor.cpp:206: DB::PipelineExecutor::finalizeExecution() @ 0x00000000169b13ba 8. /build/src/Processors/Executors/PipelineExecutor.cpp:181: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x00000000169b1726 9. /build/src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x00000000169c081c 10. /build/src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x00000000169c0978 11. /build/src/Interpreters/InterpreterKillQueryQuery.cpp:439: DB::InterpreterKillQueryQuery::getSelectResult(String const&, String const&) @ 0x0000000014cf0f04 12. /build/src/Interpreters/InterpreterKillQueryQuery.cpp:222: DB::InterpreterKillQueryQuery::execute() @ 0x0000000014cebde2 13. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88dc9 14. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 15. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 16. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 17. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 18. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 19. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 20. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 21. ? @ 0x00007fbc6213eac3 22. ? @ 0x00007fbc621d0850 2025.07.28 12:02:22.575020 [ 3964 ] {} test_13.rmt2 (7f9b740d-015c-470e-8cc6-8ba33be0dc63): auto DB::StorageReplicatedMergeTree::processQueueEntry(ReplicatedMergeTreeQueue::SelectedEntryPtr)::(anonymous class)::operator()(LogEntryPtr &) const: Code: 86. DB::HTTPException: Received error from remote server http://146b4357c08d:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Ftest%2F01165%2Ftest_13%2Frmt%2Freplicas%2F1&part=20250728_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.6.10636.altinitytest (altinity build)) '. (RECEIVED_ERROR_FROM_REMOTE_IO_SERVER), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.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 const&, int&&, String const&, unsigned long&&, String const&) @ 0x000000000feda8d9 4. /build/src/IO/HTTPCommon.cpp:104: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x000000000feda6e2 5. /build/src/IO/HTTPCommon.cpp:93: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x000000000feda537 6. /build/src/IO/ReadWriteBufferFromHTTP.cpp:277: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x000000001184a4c4 7. /build/src/IO/ReadWriteBufferFromHTTP.cpp:285: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x000000001184a615 8. /build/src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x000000001184ae59 9. /build/src/IO/ReadWriteBufferFromHTTP.cpp:472: void std::__function::__policy_invoker::__call_impl[abi:se190107]>(std::__function::__policy_storage const*) @ 0x000000001184cedd 10. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001184858b 11. /build/src/IO/ReadWriteBufferFromHTTP.cpp:465: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x000000001184bf0b 12. /build/src/IO/ReadBuffer.h:60: DB::ReadBuffer::next() @ 0x000000000a148c7b 13. /build/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) @ 0x0000000011849fb2 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]>&)>&, 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&) @ 0x0000000011841980 15. /build/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) @ 0x000000001621208e 16. /build/src/Storages/StorageReplicatedMergeTree.cpp:5228: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl[abi:se190107] const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000015f9a5fe 17. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000015ed8bfd 18. /build/src/Storages/StorageReplicatedMergeTree.cpp:2514: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x0000000015ec9aab 19. /build/src/Storages/StorageReplicatedMergeTree.cpp:2349: DB::StorageReplicatedMergeTree::executeLogEntry(DB::ReplicatedMergeTreeLogEntry&) @ 0x0000000015eba91b 20. /build/src/Storages/StorageReplicatedMergeTree.cpp:3876: bool std::__function::__policy_invoker&)>::__call_impl[abi:se190107])::$_1, bool (std::shared_ptr&)>>(std::__function::__policy_storage const*, std::shared_ptr&) @ 0x0000000015f9837e 21. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000165d6fc3 22. /build/src/Storages/StorageReplicatedMergeTree.cpp:3872: DB::StorageReplicatedMergeTree::processQueueEntry(std::shared_ptr) @ 0x0000000015efc18a 23. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001624c1b2 24. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000162f9c70 25. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x00000000162fa55a 26. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc6653 27. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000000fccc4c3 28. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc3d92 29. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fcca080 30. ? @ 0x00007fbc6213eac3 31. ? @ 0x00007fbc621d0850 (version 25.3.6.10636.altinitytest (altinity build)) 2025.07.28 12:02:22.600884 [ 17256 ] {fd842f83-a266-4880-9538-9c21a907e6e6} executeQuery: Code: 394. DB::Exception: Query was cancelled. (QUERY_WAS_CANCELLED) (version 25.3.6.10636.altinitytest (altinity build)) (from [::1]:33294) (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. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000000a074fcb 4. /build/src/Interpreters/ProcessList.cpp:567: DB::QueryStatus::throwQueryWasCancelled() const @ 0x0000000014a4bc85 5. /build/src/Interpreters/ProcessList.cpp:520: DB::QueryStatus::throwProperExceptionIfNeeded(unsigned long const&, unsigned long const&) @ 0x0000000014a4bbd9 6. /build/src/Interpreters/ProcessList.cpp:557: DB::QueryStatus::checkTimeLimit() @ 0x0000000014a4c2cd 7. /build/src/Processors/Executors/PipelineExecutor.cpp:206: DB::PipelineExecutor::finalizeExecution() @ 0x00000000169b13ba 8. /build/src/Processors/Executors/PipelineExecutor.cpp:153: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x00000000169b0584 9. /build/src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:se190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169bfeab 10. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc3d92 11. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fcca080 12. ? @ 0x00007fbc6213eac3 13. ? @ 0x00007fbc621d0850 2025.07.28 12:02:22.602263 [ 62093 ] {55aab286-16bb-4477-87f0-b29c1e65995e} executeQuery: Code: 394. DB::Exception: Query was cancelled. (QUERY_WAS_CANCELLED) (version 25.3.6.10636.altinitytest (altinity build)) (from [::1]:33378) (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. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000000a074fcb 4. /build/src/Interpreters/ProcessList.cpp:567: DB::QueryStatus::throwQueryWasCancelled() const @ 0x0000000014a4bc85 5. /build/src/Interpreters/ProcessList.cpp:520: DB::QueryStatus::throwProperExceptionIfNeeded(unsigned long const&, unsigned long const&) @ 0x0000000014a4bbd9 6. /build/src/Interpreters/ProcessList.cpp:557: DB::QueryStatus::checkTimeLimit() @ 0x0000000014a4c2cd 7. /build/src/Processors/Executors/PipelineExecutor.cpp:206: DB::PipelineExecutor::finalizeExecution() @ 0x00000000169b13ba 8. /build/src/Processors/Executors/PipelineExecutor.cpp:153: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x00000000169b0584 9. /build/src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:se190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169bfeab 10. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc3d92 11. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fcca080 12. ? @ 0x00007fbc6213eac3 13. ? @ 0x00007fbc621d0850 2025.07.28 12:02:22.615823 [ 17256 ] {} TCPHandler: Code: 394. DB::Exception: Query was cancelled. (QUERY_WAS_CANCELLED), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000000a074fcb 4. /build/src/Interpreters/ProcessList.cpp:567: DB::QueryStatus::throwQueryWasCancelled() const @ 0x0000000014a4bc85 5. /build/src/Interpreters/ProcessList.cpp:520: DB::QueryStatus::throwProperExceptionIfNeeded(unsigned long const&, unsigned long const&) @ 0x0000000014a4bbd9 6. /build/src/Interpreters/ProcessList.cpp:557: DB::QueryStatus::checkTimeLimit() @ 0x0000000014a4c2cd 7. /build/src/Processors/Executors/PipelineExecutor.cpp:206: DB::PipelineExecutor::finalizeExecution() @ 0x00000000169b13ba 8. /build/src/Processors/Executors/PipelineExecutor.cpp:153: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x00000000169b0584 9. /build/src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:se190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169bfeab 10. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc3d92 11. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fcca080 12. ? @ 0x00007fbc6213eac3 13. ? @ 0x00007fbc621d0850 Job's origin stack trace: 0. /build/src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000000fc33b84 1. /build/src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000000fcc2ea7 2. /build/src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fcc535c 3. /build/src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000000fcc584d 4. /build/src/Common/ThreadPool.h:279: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x00000000169bf193 5. /build/src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x00000000169bf518 6. /build/src/Server/TCPHandler.cpp:1237: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x00000000168f1525 7. /build/src/Server/TCPHandler.cpp:678: DB::TCPHandler::runImpl() @ 0x00000000168e68e5 8. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 9. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 10. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 11. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 12. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 13. ? @ 0x00007fbc6213eac3 14. ? @ 0x00007fbc621d0850 2025.07.28 12:02:22.704223 [ 62093 ] {} TCPHandler: Code: 394. DB::Exception: Query was cancelled. (QUERY_WAS_CANCELLED), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000000a074fcb 4. /build/src/Interpreters/ProcessList.cpp:567: DB::QueryStatus::throwQueryWasCancelled() const @ 0x0000000014a4bc85 5. /build/src/Interpreters/ProcessList.cpp:520: DB::QueryStatus::throwProperExceptionIfNeeded(unsigned long const&, unsigned long const&) @ 0x0000000014a4bbd9 6. /build/src/Interpreters/ProcessList.cpp:557: DB::QueryStatus::checkTimeLimit() @ 0x0000000014a4c2cd 7. /build/src/Processors/Executors/PipelineExecutor.cpp:206: DB::PipelineExecutor::finalizeExecution() @ 0x00000000169b13ba 8. /build/src/Processors/Executors/PipelineExecutor.cpp:153: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x00000000169b0584 9. /build/src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:se190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169bfeab 10. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc3d92 11. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fcca080 12. ? @ 0x00007fbc6213eac3 13. ? @ 0x00007fbc621d0850 Job's origin stack trace: 0. /build/src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000000fc33b84 1. /build/src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000000fcc2ea7 2. /build/src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fcc535c 3. /build/src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000000fcc584d 4. /build/src/Common/ThreadPool.h:279: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x00000000169bf193 5. /build/src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x00000000169bf518 6. /build/src/Server/TCPHandler.cpp:1237: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x00000000168f1525 7. /build/src/Server/TCPHandler.cpp:678: DB::TCPHandler::runImpl() @ 0x00000000168e68e5 8. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 9. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 10. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 11. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 12. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 13. ? @ 0x00007fbc6213eac3 14. ? @ 0x00007fbc621d0850 2025.07.28 12:02:22.778039 [ 62058 ] {} TCPHandler: Code: 394. DB::Exception: Query was cancelled. (QUERY_WAS_CANCELLED), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000000a074fcb 4. /build/src/Interpreters/ProcessList.cpp:567: DB::QueryStatus::throwQueryWasCancelled() const @ 0x0000000014a4bc85 5. /build/src/Interpreters/ProcessList.cpp:520: DB::QueryStatus::throwProperExceptionIfNeeded(unsigned long const&, unsigned long const&) @ 0x0000000014a4bbd9 6. /build/src/Interpreters/ProcessList.cpp:557: DB::QueryStatus::checkTimeLimit() @ 0x0000000014a4c2cd 7. /build/src/Processors/Executors/PipelineExecutor.cpp:206: DB::PipelineExecutor::finalizeExecution() @ 0x00000000169b13ba 8. /build/src/Processors/Executors/PipelineExecutor.cpp:181: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x00000000169b1726 9. /build/src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x00000000169c081c 10. /build/src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x00000000169c0978 11. /build/src/Interpreters/InterpreterKillQueryQuery.cpp:439: DB::InterpreterKillQueryQuery::getSelectResult(String const&, String const&) @ 0x0000000014cf0f04 12. /build/src/Interpreters/InterpreterKillQueryQuery.cpp:222: DB::InterpreterKillQueryQuery::execute() @ 0x0000000014cebde2 13. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88dc9 14. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 15. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 16. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 17. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 18. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 19. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 20. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 21. ? @ 0x00007fbc6213eac3 22. ? @ 0x00007fbc621d0850 2025.07.28 12:02:22.795948 [ 3965 ] {} test_13.rmt2 (7f9b740d-015c-470e-8cc6-8ba33be0dc63): auto DB::StorageReplicatedMergeTree::processQueueEntry(ReplicatedMergeTreeQueue::SelectedEntryPtr)::(anonymous class)::operator()(LogEntryPtr &) const: Code: 86. DB::HTTPException: Received error from remote server http://146b4357c08d:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Ftest%2F01165%2Ftest_13%2Frmt%2Freplicas%2F1&part=20250728_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.6.10636.altinitytest (altinity build)) '. (RECEIVED_ERROR_FROM_REMOTE_IO_SERVER), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.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 const&, int&&, String const&, unsigned long&&, String const&) @ 0x000000000feda8d9 4. /build/src/IO/HTTPCommon.cpp:104: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x000000000feda6e2 5. /build/src/IO/HTTPCommon.cpp:93: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x000000000feda537 6. /build/src/IO/ReadWriteBufferFromHTTP.cpp:277: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x000000001184a4c4 7. /build/src/IO/ReadWriteBufferFromHTTP.cpp:285: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x000000001184a615 8. /build/src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x000000001184ae59 9. /build/src/IO/ReadWriteBufferFromHTTP.cpp:472: void std::__function::__policy_invoker::__call_impl[abi:se190107]>(std::__function::__policy_storage const*) @ 0x000000001184cedd 10. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001184858b 11. /build/src/IO/ReadWriteBufferFromHTTP.cpp:465: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x000000001184bf0b 12. /build/src/IO/ReadBuffer.h:60: DB::ReadBuffer::next() @ 0x000000000a148c7b 13. /build/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) @ 0x0000000011849fb2 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]>&)>&, 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&) @ 0x0000000011841980 15. /build/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) @ 0x000000001621208e 16. /build/src/Storages/StorageReplicatedMergeTree.cpp:5228: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl[abi:se190107] const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000015f9a5fe 17. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000015ed8bfd 18. /build/src/Storages/StorageReplicatedMergeTree.cpp:2514: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x0000000015ec9aab 19. /build/src/Storages/StorageReplicatedMergeTree.cpp:2349: DB::StorageReplicatedMergeTree::executeLogEntry(DB::ReplicatedMergeTreeLogEntry&) @ 0x0000000015eba91b 20. /build/src/Storages/StorageReplicatedMergeTree.cpp:3876: bool std::__function::__policy_invoker&)>::__call_impl[abi:se190107])::$_1, bool (std::shared_ptr&)>>(std::__function::__policy_storage const*, std::shared_ptr&) @ 0x0000000015f9837e 21. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000165d6fc3 22. /build/src/Storages/StorageReplicatedMergeTree.cpp:3872: DB::StorageReplicatedMergeTree::processQueueEntry(std::shared_ptr) @ 0x0000000015efc18a 23. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001624c1b2 24. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000162f9c70 25. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x00000000162fa55a 26. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc6653 27. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000000fccc4c3 28. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc3d92 29. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fcca080 30. ? @ 0x00007fbc6213eac3 31. ? @ 0x00007fbc621d0850 (version 25.3.6.10636.altinitytest (altinity build)) 2025.07.28 12:02:22.848469 [ 17203 ] {} TCPHandler: Code: 394. DB::Exception: Query was cancelled. (QUERY_WAS_CANCELLED), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000000a074fcb 4. /build/src/Interpreters/ProcessList.cpp:567: DB::QueryStatus::throwQueryWasCancelled() const @ 0x0000000014a4bc85 5. /build/src/Interpreters/ProcessList.cpp:520: DB::QueryStatus::throwProperExceptionIfNeeded(unsigned long const&, unsigned long const&) @ 0x0000000014a4bbd9 6. /build/src/Interpreters/ProcessList.cpp:531: DB::QueryStatus::addPipelineExecutor(DB::PipelineExecutor*) @ 0x0000000014a4bd9c 7. /build/src/Processors/Executors/PipelineExecutor.cpp:73: DB::PipelineExecutor::PipelineExecutor(std::shared_ptr, std::allocator>>>&, std::shared_ptr) @ 0x00000000169afe31 8. /build/contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x00000000169c07b5 9. /build/src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x00000000169c0978 10. /build/src/Interpreters/InterpreterKillQueryQuery.cpp:439: DB::InterpreterKillQueryQuery::getSelectResult(String const&, String const&) @ 0x0000000014cf0f04 11. /build/src/Interpreters/InterpreterKillQueryQuery.cpp:222: DB::InterpreterKillQueryQuery::execute() @ 0x0000000014cebde2 12. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88dc9 13. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 14. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 15. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 16. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 17. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 18. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 19. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 20. ? @ 0x00007fbc6213eac3 21. ? @ 0x00007fbc621d0850 2025.07.28 12:02:22.941322 [ 4446 ] {} TCPHandler: Code: 394. DB::Exception: Query was cancelled. (QUERY_WAS_CANCELLED), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000000a074fcb 4. /build/src/Interpreters/ProcessList.cpp:567: DB::QueryStatus::throwQueryWasCancelled() const @ 0x0000000014a4bc85 5. /build/src/Interpreters/ProcessList.cpp:520: DB::QueryStatus::throwProperExceptionIfNeeded(unsigned long const&, unsigned long const&) @ 0x0000000014a4bbd9 6. /build/src/Interpreters/ProcessList.cpp:557: DB::QueryStatus::checkTimeLimit() @ 0x0000000014a4c2cd 7. /build/src/Processors/Executors/PipelineExecutor.cpp:206: DB::PipelineExecutor::finalizeExecution() @ 0x00000000169b13ba 8. /build/src/Processors/Executors/PipelineExecutor.cpp:181: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x00000000169b1726 9. /build/src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x00000000169c081c 10. /build/src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x00000000169c0978 11. /build/src/Interpreters/InterpreterKillQueryQuery.cpp:439: DB::InterpreterKillQueryQuery::getSelectResult(String const&, String const&) @ 0x0000000014cf0f04 12. /build/src/Interpreters/InterpreterKillQueryQuery.cpp:222: DB::InterpreterKillQueryQuery::execute() @ 0x0000000014cebde2 13. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88dc9 14. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 15. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 16. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 17. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 18. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 19. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 20. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 21. ? @ 0x00007fbc6213eac3 22. ? @ 0x00007fbc621d0850 2025.07.28 12:02:22.941341 [ 17255 ] {} TCPHandler: Code: 394. DB::Exception: Query was cancelled. (QUERY_WAS_CANCELLED), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000000a074fcb 4. /build/src/Interpreters/ProcessList.cpp:567: DB::QueryStatus::throwQueryWasCancelled() const @ 0x0000000014a4bc85 5. /build/src/Interpreters/ProcessList.cpp:520: DB::QueryStatus::throwProperExceptionIfNeeded(unsigned long const&, unsigned long const&) @ 0x0000000014a4bbd9 6. /build/src/Interpreters/ProcessList.cpp:557: DB::QueryStatus::checkTimeLimit() @ 0x0000000014a4c2cd 7. /build/src/Processors/Executors/PipelineExecutor.cpp:206: DB::PipelineExecutor::finalizeExecution() @ 0x00000000169b13ba 8. /build/src/Processors/Executors/PipelineExecutor.cpp:181: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x00000000169b1726 9. /build/src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x00000000169c081c 10. /build/src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x00000000169c0978 11. /build/src/Interpreters/InterpreterKillQueryQuery.cpp:442: DB::InterpreterKillQueryQuery::getSelectResult(String const&, String const&) @ 0x0000000014cf0f6b 12. /build/src/Interpreters/InterpreterKillQueryQuery.cpp:222: DB::InterpreterKillQueryQuery::execute() @ 0x0000000014cebde2 13. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88dc9 14. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 15. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 16. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 17. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 18. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 19. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 20. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 21. ? @ 0x00007fbc6213eac3 22. ? @ 0x00007fbc621d0850 2025.07.28 12:02:22.949386 [ 62056 ] {} TCPHandler: Code: 394. DB::Exception: Query was cancelled. (QUERY_WAS_CANCELLED), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000000a074fcb 4. /build/src/Interpreters/ProcessList.cpp:567: DB::QueryStatus::throwQueryWasCancelled() const @ 0x0000000014a4bc85 5. /build/src/Interpreters/ProcessList.cpp:520: DB::QueryStatus::throwProperExceptionIfNeeded(unsigned long const&, unsigned long const&) @ 0x0000000014a4bbd9 6. /build/src/Interpreters/ProcessList.cpp:531: DB::QueryStatus::addPipelineExecutor(DB::PipelineExecutor*) @ 0x0000000014a4bd9c 7. /build/src/Processors/Executors/PipelineExecutor.cpp:73: DB::PipelineExecutor::PipelineExecutor(std::shared_ptr, std::allocator>>>&, std::shared_ptr) @ 0x00000000169afe31 8. /build/contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x00000000169c07b5 9. /build/src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x00000000169c0978 10. /build/src/Interpreters/InterpreterKillQueryQuery.cpp:439: DB::InterpreterKillQueryQuery::getSelectResult(String const&, String const&) @ 0x0000000014cf0f04 11. /build/src/Interpreters/InterpreterKillQueryQuery.cpp:222: DB::InterpreterKillQueryQuery::execute() @ 0x0000000014cebde2 12. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88dc9 13. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 14. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 15. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 16. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 17. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 18. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 19. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 20. ? @ 0x00007fbc6213eac3 21. ? @ 0x00007fbc621d0850 2025.07.28 12:02:22.952735 [ 17611 ] {22259fa2-d7d4-42ba-8d47-b017e2c07122} executeQuery: Code: 394. DB::Exception: Query was cancelled. (QUERY_WAS_CANCELLED) (version 25.3.6.10636.altinitytest (altinity build)) (from [::1]:33410) (comment: 02461_cancel_finish_race.sh) (query 1, line 1) (in query: KILL QUERY WHERE current_database = 'test_dtwle8fg' SYNC FORMAT Null), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000000a074fcb 4. /build/src/Interpreters/ProcessList.cpp:567: DB::QueryStatus::throwQueryWasCancelled() const @ 0x0000000014a4bc85 5. /build/src/Interpreters/ProcessList.cpp:520: DB::QueryStatus::throwProperExceptionIfNeeded(unsigned long const&, unsigned long const&) @ 0x0000000014a4bbd9 6. /build/src/Interpreters/ProcessList.cpp:557: DB::QueryStatus::checkTimeLimit() @ 0x0000000014a4c2cd 7. /build/src/Processors/Executors/PipelineExecutor.cpp:206: DB::PipelineExecutor::finalizeExecution() @ 0x00000000169b13ba 8. /build/src/Processors/Executors/PipelineExecutor.cpp:153: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x00000000169b0584 9. /build/src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:se190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169bfeab 10. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc3d92 11. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fcca080 12. ? @ 0x00007fbc6213eac3 13. ? @ 0x00007fbc621d0850 2025.07.28 12:02:22.956481 [ 17611 ] {} TCPHandler: Code: 394. DB::Exception: Query was cancelled. (QUERY_WAS_CANCELLED), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000000a074fcb 4. /build/src/Interpreters/ProcessList.cpp:567: DB::QueryStatus::throwQueryWasCancelled() const @ 0x0000000014a4bc85 5. /build/src/Interpreters/ProcessList.cpp:520: DB::QueryStatus::throwProperExceptionIfNeeded(unsigned long const&, unsigned long const&) @ 0x0000000014a4bbd9 6. /build/src/Interpreters/ProcessList.cpp:557: DB::QueryStatus::checkTimeLimit() @ 0x0000000014a4c2cd 7. /build/src/Processors/Executors/PipelineExecutor.cpp:206: DB::PipelineExecutor::finalizeExecution() @ 0x00000000169b13ba 8. /build/src/Processors/Executors/PipelineExecutor.cpp:153: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x00000000169b0584 9. /build/src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:se190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169bfeab 10. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc3d92 11. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fcca080 12. ? @ 0x00007fbc6213eac3 13. ? @ 0x00007fbc621d0850 Job's origin stack trace: 0. /build/src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000000fc33b84 1. /build/src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000000fcc2ea7 2. /build/src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fcc535c 3. /build/src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000000fcc584d 4. /build/src/Common/ThreadPool.h:279: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x00000000169bf193 5. /build/src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x00000000169bf518 6. /build/src/Server/TCPHandler.cpp:1237: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x00000000168f1525 7. /build/src/Server/TCPHandler.cpp:678: DB::TCPHandler::runImpl() @ 0x00000000168e68e5 8. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 9. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 10. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 11. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 12. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 13. ? @ 0x00007fbc6213eac3 14. ? @ 0x00007fbc621d0850 2025.07.28 12:02:23.085285 [ 3961 ] {} test_13.rmt2 (7f9b740d-015c-470e-8cc6-8ba33be0dc63): auto DB::StorageReplicatedMergeTree::processQueueEntry(ReplicatedMergeTreeQueue::SelectedEntryPtr)::(anonymous class)::operator()(LogEntryPtr &) const: Code: 86. DB::HTTPException: Received error from remote server http://146b4357c08d:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Ftest%2F01165%2Ftest_13%2Frmt%2Freplicas%2F1&part=20250728_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.6.10636.altinitytest (altinity build)) '. (RECEIVED_ERROR_FROM_REMOTE_IO_SERVER), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.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 const&, int&&, String const&, unsigned long&&, String const&) @ 0x000000000feda8d9 4. /build/src/IO/HTTPCommon.cpp:104: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x000000000feda6e2 5. /build/src/IO/HTTPCommon.cpp:93: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x000000000feda537 6. /build/src/IO/ReadWriteBufferFromHTTP.cpp:277: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x000000001184a4c4 7. /build/src/IO/ReadWriteBufferFromHTTP.cpp:285: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x000000001184a615 8. /build/src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x000000001184ae59 9. /build/src/IO/ReadWriteBufferFromHTTP.cpp:472: void std::__function::__policy_invoker::__call_impl[abi:se190107]>(std::__function::__policy_storage const*) @ 0x000000001184cedd 10. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001184858b 11. /build/src/IO/ReadWriteBufferFromHTTP.cpp:465: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x000000001184bf0b 12. /build/src/IO/ReadBuffer.h:60: DB::ReadBuffer::next() @ 0x000000000a148c7b 13. /build/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) @ 0x0000000011849fb2 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]>&)>&, 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&) @ 0x0000000011841980 15. /build/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) @ 0x000000001621208e 16. /build/src/Storages/StorageReplicatedMergeTree.cpp:5228: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl[abi:se190107] const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000015f9a5fe 17. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000015ed8bfd 18. /build/src/Storages/StorageReplicatedMergeTree.cpp:2514: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x0000000015ec9aab 19. /build/src/Storages/StorageReplicatedMergeTree.cpp:2349: DB::StorageReplicatedMergeTree::executeLogEntry(DB::ReplicatedMergeTreeLogEntry&) @ 0x0000000015eba91b 20. /build/src/Storages/StorageReplicatedMergeTree.cpp:3876: bool std::__function::__policy_invoker&)>::__call_impl[abi:se190107])::$_1, bool (std::shared_ptr&)>>(std::__function::__policy_storage const*, std::shared_ptr&) @ 0x0000000015f9837e 21. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000165d6fc3 22. /build/src/Storages/StorageReplicatedMergeTree.cpp:3872: DB::StorageReplicatedMergeTree::processQueueEntry(std::shared_ptr) @ 0x0000000015efc18a 23. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001624c1b2 24. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000162f9c70 25. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x00000000162fa55a 26. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc6653 27. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000000fccc4c3 28. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc3d92 29. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fcca080 30. ? @ 0x00007fbc6213eac3 31. ? @ 0x00007fbc621d0850 (version 25.3.6.10636.altinitytest (altinity build)) 2025.07.28 12:02:23.179932 [ 62114 ] {} TCPHandler: Code: 394. DB::Exception: Query was cancelled. (QUERY_WAS_CANCELLED), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000000a074fcb 4. /build/src/Interpreters/ProcessList.cpp:567: DB::QueryStatus::throwQueryWasCancelled() const @ 0x0000000014a4bc85 5. /build/src/Interpreters/ProcessList.cpp:520: DB::QueryStatus::throwProperExceptionIfNeeded(unsigned long const&, unsigned long const&) @ 0x0000000014a4bbd9 6. /build/src/Interpreters/ProcessList.cpp:557: DB::QueryStatus::checkTimeLimit() @ 0x0000000014a4c2cd 7. /build/src/Processors/Executors/PipelineExecutor.cpp:206: DB::PipelineExecutor::finalizeExecution() @ 0x00000000169b13ba 8. /build/src/Processors/Executors/PipelineExecutor.cpp:181: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x00000000169b1726 9. /build/src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x00000000169c081c 10. /build/src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x00000000169c0978 11. /build/src/Interpreters/InterpreterKillQueryQuery.cpp:439: DB::InterpreterKillQueryQuery::getSelectResult(String const&, String const&) @ 0x0000000014cf0f04 12. /build/src/Interpreters/InterpreterKillQueryQuery.cpp:222: DB::InterpreterKillQueryQuery::execute() @ 0x0000000014cebde2 13. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88dc9 14. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 15. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 16. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 17. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 18. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 19. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 20. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 21. ? @ 0x00007fbc6213eac3 22. ? @ 0x00007fbc621d0850 2025.07.28 12:02:23.362349 [ 62055 ] {fae0ce11-84ae-4297-9b28-9f2579397690} executeQuery: Code: 394. DB::Exception: Query was cancelled. (QUERY_WAS_CANCELLED) (version 25.3.6.10636.altinitytest (altinity build)) (from [::1]:33638) (comment: 02461_cancel_finish_race.sh) (query 1, line 1) (in query: KILL QUERY WHERE current_database = 'test_dtwle8fg' SYNC FORMAT Null), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000000a074fcb 4. /build/src/Interpreters/ProcessList.cpp:567: DB::QueryStatus::throwQueryWasCancelled() const @ 0x0000000014a4bc85 5. /build/src/Interpreters/ProcessList.cpp:520: DB::QueryStatus::throwProperExceptionIfNeeded(unsigned long const&, unsigned long const&) @ 0x0000000014a4bbd9 6. /build/src/Interpreters/ProcessList.cpp:557: DB::QueryStatus::checkTimeLimit() @ 0x0000000014a4c2cd 7. /build/src/Processors/Executors/PipelineExecutor.cpp:206: DB::PipelineExecutor::finalizeExecution() @ 0x00000000169b13ba 8. /build/src/Processors/Executors/PipelineExecutor.cpp:153: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x00000000169b0584 9. /build/src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:se190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169bfeab 10. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc3d92 11. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fcca080 12. ? @ 0x00007fbc6213eac3 13. ? @ 0x00007fbc621d0850 2025.07.28 12:02:23.376359 [ 5951 ] {07076ff6-81c6-45fe-a4e4-0e56af7ecc1d} executeQuery: Code: 394. DB::Exception: Query was cancelled. (QUERY_WAS_CANCELLED) (version 25.3.6.10636.altinitytest (altinity build)) (from [::1]:33634) (comment: 02461_cancel_finish_race.sh) (query 1, line 1) (in query: KILL QUERY WHERE current_database = 'test_dtwle8fg' SYNC FORMAT Null), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000000a074fcb 4. /build/src/Interpreters/ProcessList.cpp:567: DB::QueryStatus::throwQueryWasCancelled() const @ 0x0000000014a4bc85 5. /build/src/Interpreters/ProcessList.cpp:520: DB::QueryStatus::throwProperExceptionIfNeeded(unsigned long const&, unsigned long const&) @ 0x0000000014a4bbd9 6. /build/src/Interpreters/ProcessList.cpp:557: DB::QueryStatus::checkTimeLimit() @ 0x0000000014a4c2cd 7. /build/src/Processors/Executors/PipelineExecutor.cpp:206: DB::PipelineExecutor::finalizeExecution() @ 0x00000000169b13ba 8. /build/src/Processors/Executors/PipelineExecutor.cpp:153: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x00000000169b0584 9. /build/src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:se190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169bfeab 10. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc3d92 11. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fcca080 12. ? @ 0x00007fbc6213eac3 13. ? @ 0x00007fbc621d0850 2025.07.28 12:02:23.392428 [ 62055 ] {} TCPHandler: Code: 394. DB::Exception: Query was cancelled. (QUERY_WAS_CANCELLED), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000000a074fcb 4. /build/src/Interpreters/ProcessList.cpp:567: DB::QueryStatus::throwQueryWasCancelled() const @ 0x0000000014a4bc85 5. /build/src/Interpreters/ProcessList.cpp:520: DB::QueryStatus::throwProperExceptionIfNeeded(unsigned long const&, unsigned long const&) @ 0x0000000014a4bbd9 6. /build/src/Interpreters/ProcessList.cpp:557: DB::QueryStatus::checkTimeLimit() @ 0x0000000014a4c2cd 7. /build/src/Processors/Executors/PipelineExecutor.cpp:206: DB::PipelineExecutor::finalizeExecution() @ 0x00000000169b13ba 8. /build/src/Processors/Executors/PipelineExecutor.cpp:153: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x00000000169b0584 9. /build/src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:se190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169bfeab 10. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc3d92 11. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fcca080 12. ? @ 0x00007fbc6213eac3 13. ? @ 0x00007fbc621d0850 Job's origin stack trace: 0. /build/src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000000fc33b84 1. /build/src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000000fcc2ea7 2. /build/src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fcc535c 3. /build/src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000000fcc584d 4. /build/src/Common/ThreadPool.h:279: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x00000000169bf193 5. /build/src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x00000000169bf518 6. /build/src/Server/TCPHandler.cpp:1237: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x00000000168f1525 7. /build/src/Server/TCPHandler.cpp:678: DB::TCPHandler::runImpl() @ 0x00000000168e68e5 8. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 9. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 10. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 11. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 12. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 13. ? @ 0x00007fbc6213eac3 14. ? @ 0x00007fbc621d0850 2025.07.28 12:02:23.410999 [ 5951 ] {} TCPHandler: Code: 394. DB::Exception: Query was cancelled. (QUERY_WAS_CANCELLED), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000000a074fcb 4. /build/src/Interpreters/ProcessList.cpp:567: DB::QueryStatus::throwQueryWasCancelled() const @ 0x0000000014a4bc85 5. /build/src/Interpreters/ProcessList.cpp:520: DB::QueryStatus::throwProperExceptionIfNeeded(unsigned long const&, unsigned long const&) @ 0x0000000014a4bbd9 6. /build/src/Interpreters/ProcessList.cpp:557: DB::QueryStatus::checkTimeLimit() @ 0x0000000014a4c2cd 7. /build/src/Processors/Executors/PipelineExecutor.cpp:206: DB::PipelineExecutor::finalizeExecution() @ 0x00000000169b13ba 8. /build/src/Processors/Executors/PipelineExecutor.cpp:153: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x00000000169b0584 9. /build/src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:se190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169bfeab 10. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc3d92 11. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fcca080 12. ? @ 0x00007fbc6213eac3 13. ? @ 0x00007fbc621d0850 Job's origin stack trace: 0. /build/src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000000fc33b84 1. /build/src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000000fcc2ea7 2. /build/src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fcc535c 3. /build/src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000000fcc584d 4. /build/src/Common/ThreadPool.h:279: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x00000000169bf193 5. /build/src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x00000000169bf518 6. /build/src/Server/TCPHandler.cpp:1237: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x00000000168f1525 7. /build/src/Server/TCPHandler.cpp:678: DB::TCPHandler::runImpl() @ 0x00000000168e68e5 8. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 9. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 10. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 11. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 12. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 13. ? @ 0x00007fbc6213eac3 14. ? @ 0x00007fbc621d0850 2025.07.28 12:02:23.413095 [ 62053 ] {5424f6f3-9859-4c3b-853a-b53b663faef4} executeQuery: Code: 394. DB::Exception: Query was cancelled. (QUERY_WAS_CANCELLED) (version 25.3.6.10636.altinitytest (altinity build)) (from [::1]:33650) (comment: 02461_cancel_finish_race.sh) (query 1, line 1) (in query: KILL QUERY WHERE current_database = 'test_dtwle8fg' SYNC FORMAT Null), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000000a074fcb 4. /build/src/Interpreters/ProcessList.cpp:567: DB::QueryStatus::throwQueryWasCancelled() const @ 0x0000000014a4bc85 5. /build/src/Interpreters/ProcessList.cpp:520: DB::QueryStatus::throwProperExceptionIfNeeded(unsigned long const&, unsigned long const&) @ 0x0000000014a4bbd9 6. /build/src/Interpreters/ProcessList.cpp:557: DB::QueryStatus::checkTimeLimit() @ 0x0000000014a4c2cd 7. /build/src/Processors/Executors/PipelineExecutor.cpp:206: DB::PipelineExecutor::finalizeExecution() @ 0x00000000169b13ba 8. /build/src/Processors/Executors/PipelineExecutor.cpp:153: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x00000000169b0584 9. /build/src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:se190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169bfeab 10. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc3d92 11. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fcca080 12. ? @ 0x00007fbc6213eac3 13. ? @ 0x00007fbc621d0850 2025.07.28 12:02:23.444803 [ 62053 ] {} TCPHandler: Code: 394. DB::Exception: Query was cancelled. (QUERY_WAS_CANCELLED), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000000a074fcb 4. /build/src/Interpreters/ProcessList.cpp:567: DB::QueryStatus::throwQueryWasCancelled() const @ 0x0000000014a4bc85 5. /build/src/Interpreters/ProcessList.cpp:520: DB::QueryStatus::throwProperExceptionIfNeeded(unsigned long const&, unsigned long const&) @ 0x0000000014a4bbd9 6. /build/src/Interpreters/ProcessList.cpp:557: DB::QueryStatus::checkTimeLimit() @ 0x0000000014a4c2cd 7. /build/src/Processors/Executors/PipelineExecutor.cpp:206: DB::PipelineExecutor::finalizeExecution() @ 0x00000000169b13ba 8. /build/src/Processors/Executors/PipelineExecutor.cpp:153: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x00000000169b0584 9. /build/src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:se190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169bfeab 10. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc3d92 11. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fcca080 12. ? @ 0x00007fbc6213eac3 13. ? @ 0x00007fbc621d0850 Job's origin stack trace: 0. /build/src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000000fc33b84 1. /build/src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000000fcc2ea7 2. /build/src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fcc535c 3. /build/src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000000fcc584d 4. /build/src/Common/ThreadPool.h:279: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x00000000169bf193 5. /build/src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x00000000169bf518 6. /build/src/Server/TCPHandler.cpp:1237: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x00000000168f1525 7. /build/src/Server/TCPHandler.cpp:678: DB::TCPHandler::runImpl() @ 0x00000000168e68e5 8. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 9. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 10. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 11. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 12. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 13. ? @ 0x00007fbc6213eac3 14. ? @ 0x00007fbc621d0850 2025.07.28 12:02:23.460747 [ 3970 ] {} test_13.rmt2 (7f9b740d-015c-470e-8cc6-8ba33be0dc63): auto DB::StorageReplicatedMergeTree::processQueueEntry(ReplicatedMergeTreeQueue::SelectedEntryPtr)::(anonymous class)::operator()(LogEntryPtr &) const: Code: 86. DB::HTTPException: Received error from remote server http://146b4357c08d:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Ftest%2F01165%2Ftest_13%2Frmt%2Freplicas%2F1&part=20250728_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.6.10636.altinitytest (altinity build)) '. (RECEIVED_ERROR_FROM_REMOTE_IO_SERVER), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.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 const&, int&&, String const&, unsigned long&&, String const&) @ 0x000000000feda8d9 4. /build/src/IO/HTTPCommon.cpp:104: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x000000000feda6e2 5. /build/src/IO/HTTPCommon.cpp:93: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x000000000feda537 6. /build/src/IO/ReadWriteBufferFromHTTP.cpp:277: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x000000001184a4c4 7. /build/src/IO/ReadWriteBufferFromHTTP.cpp:285: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x000000001184a615 8. /build/src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x000000001184ae59 9. /build/src/IO/ReadWriteBufferFromHTTP.cpp:472: void std::__function::__policy_invoker::__call_impl[abi:se190107]>(std::__function::__policy_storage const*) @ 0x000000001184cedd 10. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001184858b 11. /build/src/IO/ReadWriteBufferFromHTTP.cpp:465: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x000000001184bf0b 12. /build/src/IO/ReadBuffer.h:60: DB::ReadBuffer::next() @ 0x000000000a148c7b 13. /build/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) @ 0x0000000011849fb2 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]>&)>&, 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&) @ 0x0000000011841980 15. /build/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) @ 0x000000001621208e 16. /build/src/Storages/StorageReplicatedMergeTree.cpp:5228: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl[abi:se190107] const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000015f9a5fe 17. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000015ed8bfd 18. /build/src/Storages/StorageReplicatedMergeTree.cpp:2514: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x0000000015ec9aab 19. /build/src/Storages/StorageReplicatedMergeTree.cpp:2349: DB::StorageReplicatedMergeTree::executeLogEntry(DB::ReplicatedMergeTreeLogEntry&) @ 0x0000000015eba91b 20. /build/src/Storages/StorageReplicatedMergeTree.cpp:3876: bool std::__function::__policy_invoker&)>::__call_impl[abi:se190107])::$_1, bool (std::shared_ptr&)>>(std::__function::__policy_storage const*, std::shared_ptr&) @ 0x0000000015f9837e 21. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000165d6fc3 22. /build/src/Storages/StorageReplicatedMergeTree.cpp:3872: DB::StorageReplicatedMergeTree::processQueueEntry(std::shared_ptr) @ 0x0000000015efc18a 23. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001624c1b2 24. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000162f9c70 25. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x00000000162fa55a 26. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc6653 27. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000000fccc4c3 28. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc3d92 29. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fcca080 30. ? @ 0x00007fbc6213eac3 31. ? @ 0x00007fbc621d0850 (version 25.3.6.10636.altinitytest (altinity build)) 2025.07.28 12:02:23.667686 [ 17243 ] {} TCPHandler: Code: 394. DB::Exception: Query was cancelled. (QUERY_WAS_CANCELLED), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000000a074fcb 4. /build/src/Interpreters/ProcessList.cpp:567: DB::QueryStatus::throwQueryWasCancelled() const @ 0x0000000014a4bc85 5. /build/src/Interpreters/ProcessList.cpp:520: DB::QueryStatus::throwProperExceptionIfNeeded(unsigned long const&, unsigned long const&) @ 0x0000000014a4bbd9 6. /build/src/Interpreters/ProcessList.cpp:557: DB::QueryStatus::checkTimeLimit() @ 0x0000000014a4c2cd 7. /build/src/Processors/Executors/PipelineExecutor.cpp:206: DB::PipelineExecutor::finalizeExecution() @ 0x00000000169b13ba 8. /build/src/Processors/Executors/PipelineExecutor.cpp:181: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x00000000169b1726 9. /build/src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x00000000169c081c 10. /build/src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x00000000169c0978 11. /build/src/Interpreters/InterpreterKillQueryQuery.cpp:439: DB::InterpreterKillQueryQuery::getSelectResult(String const&, String const&) @ 0x0000000014cf0f04 12. /build/src/Interpreters/InterpreterKillQueryQuery.cpp:222: DB::InterpreterKillQueryQuery::execute() @ 0x0000000014cebde2 13. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88dc9 14. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 15. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 16. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 17. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 18. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 19. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 20. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 21. ? @ 0x00007fbc6213eac3 22. ? @ 0x00007fbc621d0850 2025.07.28 12:02:23.719230 [ 11826 ] {} TCPHandler: Code: 394. DB::Exception: Query was cancelled. (QUERY_WAS_CANCELLED), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000000a074fcb 4. /build/src/Interpreters/ProcessList.cpp:567: DB::QueryStatus::throwQueryWasCancelled() const @ 0x0000000014a4bc85 5. /build/src/Interpreters/ProcessList.cpp:520: DB::QueryStatus::throwProperExceptionIfNeeded(unsigned long const&, unsigned long const&) @ 0x0000000014a4bbd9 6. /build/src/Interpreters/ProcessList.cpp:557: DB::QueryStatus::checkTimeLimit() @ 0x0000000014a4c2cd 7. /build/src/Processors/Executors/PipelineExecutor.cpp:206: DB::PipelineExecutor::finalizeExecution() @ 0x00000000169b13ba 8. /build/src/Processors/Executors/PipelineExecutor.cpp:181: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x00000000169b1726 9. /build/src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x00000000169c081c 10. /build/src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x00000000169c0978 11. /build/src/Interpreters/InterpreterKillQueryQuery.cpp:439: DB::InterpreterKillQueryQuery::getSelectResult(String const&, String const&) @ 0x0000000014cf0f04 12. /build/src/Interpreters/InterpreterKillQueryQuery.cpp:222: DB::InterpreterKillQueryQuery::execute() @ 0x0000000014cebde2 13. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88dc9 14. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 15. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 16. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 17. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 18. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 19. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 20. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 21. ? @ 0x00007fbc6213eac3 22. ? @ 0x00007fbc621d0850 2025.07.28 12:02:23.783996 [ 62114 ] {ed10f076-3c44-473b-ba0c-66a5952cd8e9} executeQuery: Code: 394. DB::Exception: Query was cancelled. (QUERY_WAS_CANCELLED) (version 25.3.6.10636.altinitytest (altinity build)) (from [::1]:33744) (comment: 02461_cancel_finish_race.sh) (query 1, line 1) (in query: KILL QUERY WHERE current_database = 'test_dtwle8fg' SYNC FORMAT Null), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000000a074fcb 4. /build/src/Interpreters/ProcessList.cpp:567: DB::QueryStatus::throwQueryWasCancelled() const @ 0x0000000014a4bc85 5. /build/src/Interpreters/ProcessList.cpp:520: DB::QueryStatus::throwProperExceptionIfNeeded(unsigned long const&, unsigned long const&) @ 0x0000000014a4bbd9 6. /build/src/Interpreters/ProcessList.cpp:557: DB::QueryStatus::checkTimeLimit() @ 0x0000000014a4c2cd 7. /build/src/Processors/Executors/PipelineExecutor.cpp:206: DB::PipelineExecutor::finalizeExecution() @ 0x00000000169b13ba 8. /build/src/Processors/Executors/PipelineExecutor.cpp:153: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x00000000169b0584 9. /build/src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:se190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169bfeab 10. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc3d92 11. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fcca080 12. ? @ 0x00007fbc6213eac3 13. ? @ 0x00007fbc621d0850 2025.07.28 12:02:23.789259 [ 62114 ] {} TCPHandler: Code: 394. DB::Exception: Query was cancelled. (QUERY_WAS_CANCELLED), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000000a074fcb 4. /build/src/Interpreters/ProcessList.cpp:567: DB::QueryStatus::throwQueryWasCancelled() const @ 0x0000000014a4bc85 5. /build/src/Interpreters/ProcessList.cpp:520: DB::QueryStatus::throwProperExceptionIfNeeded(unsigned long const&, unsigned long const&) @ 0x0000000014a4bbd9 6. /build/src/Interpreters/ProcessList.cpp:557: DB::QueryStatus::checkTimeLimit() @ 0x0000000014a4c2cd 7. /build/src/Processors/Executors/PipelineExecutor.cpp:206: DB::PipelineExecutor::finalizeExecution() @ 0x00000000169b13ba 8. /build/src/Processors/Executors/PipelineExecutor.cpp:153: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x00000000169b0584 9. /build/src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:se190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169bfeab 10. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc3d92 11. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fcca080 12. ? @ 0x00007fbc6213eac3 13. ? @ 0x00007fbc621d0850 Job's origin stack trace: 0. /build/src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000000fc33b84 1. /build/src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000000fcc2ea7 2. /build/src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fcc535c 3. /build/src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000000fcc584d 4. /build/src/Common/ThreadPool.h:279: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x00000000169bf193 5. /build/src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x00000000169bf518 6. /build/src/Server/TCPHandler.cpp:1237: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x00000000168f1525 7. /build/src/Server/TCPHandler.cpp:678: DB::TCPHandler::runImpl() @ 0x00000000168e68e5 8. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 9. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 10. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 11. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 12. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 13. ? @ 0x00007fbc6213eac3 14. ? @ 0x00007fbc621d0850 2025.07.28 12:02:23.810135 [ 17252 ] {} TCPHandler: Code: 394. DB::Exception: Query was cancelled. (QUERY_WAS_CANCELLED), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000000a074fcb 4. /build/src/Interpreters/ProcessList.cpp:567: DB::QueryStatus::throwQueryWasCancelled() const @ 0x0000000014a4bc85 5. /build/src/Interpreters/ProcessList.cpp:520: DB::QueryStatus::throwProperExceptionIfNeeded(unsigned long const&, unsigned long const&) @ 0x0000000014a4bbd9 6. /build/src/Interpreters/ProcessList.cpp:531: DB::QueryStatus::addPipelineExecutor(DB::PipelineExecutor*) @ 0x0000000014a4bd9c 7. /build/src/Processors/Executors/PipelineExecutor.cpp:73: DB::PipelineExecutor::PipelineExecutor(std::shared_ptr, std::allocator>>>&, std::shared_ptr) @ 0x00000000169afe31 8. /build/contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x00000000169c07b5 9. /build/src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x00000000169c0978 10. /build/src/Interpreters/InterpreterKillQueryQuery.cpp:439: DB::InterpreterKillQueryQuery::getSelectResult(String const&, String const&) @ 0x0000000014cf0f04 11. /build/src/Interpreters/InterpreterKillQueryQuery.cpp:222: DB::InterpreterKillQueryQuery::execute() @ 0x0000000014cebde2 12. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88dc9 13. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 14. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 15. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 16. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 17. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 18. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 19. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 20. ? @ 0x00007fbc6213eac3 21. ? @ 0x00007fbc621d0850 2025.07.28 12:02:23.909884 [ 4446 ] {2aeb0eb5-cb57-48f6-b2d7-b09b3f3f4b4e} executeQuery: Code: 394. DB::Exception: Query was cancelled. (QUERY_WAS_CANCELLED) (version 25.3.6.10636.altinitytest (altinity build)) (from [::1]:33704) (comment: 02461_cancel_finish_race.sh) (query 1, line 1) (in query: KILL QUERY WHERE current_database = 'test_dtwle8fg' SYNC FORMAT Null), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000000a074fcb 4. /build/src/Interpreters/ProcessList.cpp:567: DB::QueryStatus::throwQueryWasCancelled() const @ 0x0000000014a4bc85 5. /build/src/Interpreters/ProcessList.cpp:520: DB::QueryStatus::throwProperExceptionIfNeeded(unsigned long const&, unsigned long const&) @ 0x0000000014a4bbd9 6. /build/src/Interpreters/ProcessList.cpp:557: DB::QueryStatus::checkTimeLimit() @ 0x0000000014a4c2cd 7. /build/src/Processors/Executors/PipelineExecutor.cpp:206: DB::PipelineExecutor::finalizeExecution() @ 0x00000000169b13ba 8. /build/src/Processors/Executors/PipelineExecutor.cpp:153: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x00000000169b0584 9. /build/src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:se190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169bfeab 10. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc3d92 11. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fcca080 12. ? @ 0x00007fbc6213eac3 13. ? @ 0x00007fbc621d0850 2025.07.28 12:02:23.931876 [ 4446 ] {} TCPHandler: Code: 394. DB::Exception: Query was cancelled. (QUERY_WAS_CANCELLED), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000000a074fcb 4. /build/src/Interpreters/ProcessList.cpp:567: DB::QueryStatus::throwQueryWasCancelled() const @ 0x0000000014a4bc85 5. /build/src/Interpreters/ProcessList.cpp:520: DB::QueryStatus::throwProperExceptionIfNeeded(unsigned long const&, unsigned long const&) @ 0x0000000014a4bbd9 6. /build/src/Interpreters/ProcessList.cpp:557: DB::QueryStatus::checkTimeLimit() @ 0x0000000014a4c2cd 7. /build/src/Processors/Executors/PipelineExecutor.cpp:206: DB::PipelineExecutor::finalizeExecution() @ 0x00000000169b13ba 8. /build/src/Processors/Executors/PipelineExecutor.cpp:153: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x00000000169b0584 9. /build/src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:se190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169bfeab 10. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc3d92 11. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fcca080 12. ? @ 0x00007fbc6213eac3 13. ? @ 0x00007fbc621d0850 Job's origin stack trace: 0. /build/src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000000fc33b84 1. /build/src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000000fcc2ea7 2. /build/src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fcc535c 3. /build/src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000000fcc584d 4. /build/src/Common/ThreadPool.h:279: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x00000000169bf193 5. /build/src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x00000000169bf518 6. /build/src/Server/TCPHandler.cpp:1237: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x00000000168f1525 7. /build/src/Server/TCPHandler.cpp:678: DB::TCPHandler::runImpl() @ 0x00000000168e68e5 8. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 9. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 10. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 11. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 12. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 13. ? @ 0x00007fbc6213eac3 14. ? @ 0x00007fbc621d0850 2025.07.28 12:02:23.963950 [ 3974 ] {} test_13.rmt2 (7f9b740d-015c-470e-8cc6-8ba33be0dc63): auto DB::StorageReplicatedMergeTree::processQueueEntry(ReplicatedMergeTreeQueue::SelectedEntryPtr)::(anonymous class)::operator()(LogEntryPtr &) const: Code: 86. DB::HTTPException: Received error from remote server http://146b4357c08d:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Ftest%2F01165%2Ftest_13%2Frmt%2Freplicas%2F1&part=20250728_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.6.10636.altinitytest (altinity build)) '. (RECEIVED_ERROR_FROM_REMOTE_IO_SERVER), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.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 const&, int&&, String const&, unsigned long&&, String const&) @ 0x000000000feda8d9 4. /build/src/IO/HTTPCommon.cpp:104: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x000000000feda6e2 5. /build/src/IO/HTTPCommon.cpp:93: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x000000000feda537 6. /build/src/IO/ReadWriteBufferFromHTTP.cpp:277: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x000000001184a4c4 7. /build/src/IO/ReadWriteBufferFromHTTP.cpp:285: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x000000001184a615 8. /build/src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x000000001184ae59 9. /build/src/IO/ReadWriteBufferFromHTTP.cpp:472: void std::__function::__policy_invoker::__call_impl[abi:se190107]>(std::__function::__policy_storage const*) @ 0x000000001184cedd 10. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001184858b 11. /build/src/IO/ReadWriteBufferFromHTTP.cpp:465: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x000000001184bf0b 12. /build/src/IO/ReadBuffer.h:60: DB::ReadBuffer::next() @ 0x000000000a148c7b 13. /build/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) @ 0x0000000011849fb2 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]>&)>&, 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&) @ 0x0000000011841980 15. /build/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) @ 0x000000001621208e 16. /build/src/Storages/StorageReplicatedMergeTree.cpp:5228: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl[abi:se190107] const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000015f9a5fe 17. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000015ed8bfd 18. /build/src/Storages/StorageReplicatedMergeTree.cpp:2514: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x0000000015ec9aab 19. /build/src/Storages/StorageReplicatedMergeTree.cpp:2349: DB::StorageReplicatedMergeTree::executeLogEntry(DB::ReplicatedMergeTreeLogEntry&) @ 0x0000000015eba91b 20. /build/src/Storages/StorageReplicatedMergeTree.cpp:3876: bool std::__function::__policy_invoker&)>::__call_impl[abi:se190107])::$_1, bool (std::shared_ptr&)>>(std::__function::__policy_storage const*, std::shared_ptr&) @ 0x0000000015f9837e 21. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000165d6fc3 22. /build/src/Storages/StorageReplicatedMergeTree.cpp:3872: DB::StorageReplicatedMergeTree::processQueueEntry(std::shared_ptr) @ 0x0000000015efc18a 23. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001624c1b2 24. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000162f9c70 25. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x00000000162fa55a 26. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc6653 27. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000000fccc4c3 28. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc3d92 29. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fcca080 30. ? @ 0x00007fbc6213eac3 31. ? @ 0x00007fbc621d0850 (version 25.3.6.10636.altinitytest (altinity build)) 2025.07.28 12:02:23.977920 [ 5879 ] {} 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. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception>&, String>(int, FormatStringHelperImpl>&>::type, std::type_identity::type>, std::basic_string_view>&, String&&) @ 0x000000001385a5eb 4. /build/src/Access/SettingsConstraints.cpp:376: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000013859b18 5. /build/src/Access/SettingsConstraints.cpp:300: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000013858faf 6. /build/src/Access/SettingsConstraints.cpp:209: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000013859223 7. /build/src/Interpreters/Context.cpp:2690: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000014436134 8. /build/src/Interpreters/Context.cpp:2729: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x000000001443662b 9. /build/src/Server/HTTPHandler.cpp:457: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000001686d165 10. /build/src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x0000000016870807 11. /build/src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x0000000016907e99 12. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 13. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 14. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 15. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 16. ? @ 0x00007fbc6213eac3 17. ? @ 0x00007fbc621d0850 (version 25.3.6.10636.altinitytest (altinity build)) 2025.07.28 12:02:24.089063 [ 4963 ] {} TCPHandler: Code: 394. DB::Exception: Query was cancelled. (QUERY_WAS_CANCELLED), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000000a074fcb 4. /build/src/Interpreters/ProcessList.cpp:567: DB::QueryStatus::throwQueryWasCancelled() const @ 0x0000000014a4bc85 5. /build/src/Interpreters/ProcessList.cpp:520: DB::QueryStatus::throwProperExceptionIfNeeded(unsigned long const&, unsigned long const&) @ 0x0000000014a4bbd9 6. /build/src/Interpreters/ProcessList.cpp:531: DB::QueryStatus::addPipelineExecutor(DB::PipelineExecutor*) @ 0x0000000014a4bd9c 7. /build/src/Processors/Executors/PipelineExecutor.cpp:73: DB::PipelineExecutor::PipelineExecutor(std::shared_ptr, std::allocator>>>&, std::shared_ptr) @ 0x00000000169afe31 8. /build/contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x00000000169c07b5 9. /build/src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x00000000169c0978 10. /build/src/Interpreters/InterpreterKillQueryQuery.cpp:439: DB::InterpreterKillQueryQuery::getSelectResult(String const&, String const&) @ 0x0000000014cf0f04 11. /build/src/Interpreters/InterpreterKillQueryQuery.cpp:222: DB::InterpreterKillQueryQuery::execute() @ 0x0000000014cebde2 12. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88dc9 13. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 14. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 15. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 16. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 17. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 18. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 19. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 20. ? @ 0x00007fbc6213eac3 21. ? @ 0x00007fbc621d0850 2025.07.28 12:02:24.101644 [ 5112 ] {0ad8786d-ee82-481e-959d-bd7c2aa45dcb} executeQuery: Code: 394. DB::Exception: Query was cancelled. (QUERY_WAS_CANCELLED) (version 25.3.6.10636.altinitytest (altinity build)) (from [::1]:33816) (comment: 02461_cancel_finish_race.sh) (query 1, line 1) (in query: KILL QUERY WHERE current_database = 'test_dtwle8fg' SYNC FORMAT Null), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000000a074fcb 4. /build/src/Interpreters/ProcessList.cpp:567: DB::QueryStatus::throwQueryWasCancelled() const @ 0x0000000014a4bc85 5. /build/src/Interpreters/ProcessList.cpp:520: DB::QueryStatus::throwProperExceptionIfNeeded(unsigned long const&, unsigned long const&) @ 0x0000000014a4bbd9 6. /build/src/Interpreters/ProcessList.cpp:557: DB::QueryStatus::checkTimeLimit() @ 0x0000000014a4c2cd 7. /build/src/Processors/Executors/PipelineExecutor.cpp:206: DB::PipelineExecutor::finalizeExecution() @ 0x00000000169b13ba 8. /build/src/Processors/Executors/PipelineExecutor.cpp:153: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x00000000169b0584 9. /build/src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:se190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169bfeab 10. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc3d92 11. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fcca080 12. ? @ 0x00007fbc6213eac3 13. ? @ 0x00007fbc621d0850 2025.07.28 12:02:24.162722 [ 5112 ] {} TCPHandler: Code: 394. DB::Exception: Query was cancelled. (QUERY_WAS_CANCELLED), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000000a074fcb 4. /build/src/Interpreters/ProcessList.cpp:567: DB::QueryStatus::throwQueryWasCancelled() const @ 0x0000000014a4bc85 5. /build/src/Interpreters/ProcessList.cpp:520: DB::QueryStatus::throwProperExceptionIfNeeded(unsigned long const&, unsigned long const&) @ 0x0000000014a4bbd9 6. /build/src/Interpreters/ProcessList.cpp:557: DB::QueryStatus::checkTimeLimit() @ 0x0000000014a4c2cd 7. /build/src/Processors/Executors/PipelineExecutor.cpp:206: DB::PipelineExecutor::finalizeExecution() @ 0x00000000169b13ba 8. /build/src/Processors/Executors/PipelineExecutor.cpp:153: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x00000000169b0584 9. /build/src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:se190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169bfeab 10. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc3d92 11. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fcca080 12. ? @ 0x00007fbc6213eac3 13. ? @ 0x00007fbc621d0850 Job's origin stack trace: 0. /build/src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000000fc33b84 1. /build/src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000000fcc2ea7 2. /build/src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fcc535c 3. /build/src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000000fcc584d 4. /build/src/Common/ThreadPool.h:279: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x00000000169bf193 5. /build/src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x00000000169bf518 6. /build/src/Server/TCPHandler.cpp:1237: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x00000000168f1525 7. /build/src/Server/TCPHandler.cpp:678: DB::TCPHandler::runImpl() @ 0x00000000168e68e5 8. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 9. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 10. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 11. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 12. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 13. ? @ 0x00007fbc6213eac3 14. ? @ 0x00007fbc621d0850 2025.07.28 12:02:24.162523 [ 62053 ] {3746bca3-a8f1-4ab5-969e-a5b0160e5e7b} executeQuery: Code: 394. DB::Exception: Query was cancelled. (QUERY_WAS_CANCELLED) (version 25.3.6.10636.altinitytest (altinity build)) (from [::1]:33862) (comment: 02461_cancel_finish_race.sh) (query 1, line 1) (in query: KILL QUERY WHERE current_database = 'test_dtwle8fg' SYNC FORMAT Null), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000000a074fcb 4. /build/src/Interpreters/ProcessList.cpp:567: DB::QueryStatus::throwQueryWasCancelled() const @ 0x0000000014a4bc85 5. /build/src/Interpreters/ProcessList.cpp:520: DB::QueryStatus::throwProperExceptionIfNeeded(unsigned long const&, unsigned long const&) @ 0x0000000014a4bbd9 6. /build/src/Interpreters/ProcessList.cpp:557: DB::QueryStatus::checkTimeLimit() @ 0x0000000014a4c2cd 7. /build/src/Processors/Executors/PipelineExecutor.cpp:206: DB::PipelineExecutor::finalizeExecution() @ 0x00000000169b13ba 8. /build/src/Processors/Executors/PipelineExecutor.cpp:153: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x00000000169b0584 9. /build/src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:se190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169bfeab 10. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc3d92 11. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fcca080 12. ? @ 0x00007fbc6213eac3 13. ? @ 0x00007fbc621d0850 2025.07.28 12:02:24.174315 [ 62053 ] {} TCPHandler: Code: 394. DB::Exception: Query was cancelled. (QUERY_WAS_CANCELLED), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000000a074fcb 4. /build/src/Interpreters/ProcessList.cpp:567: DB::QueryStatus::throwQueryWasCancelled() const @ 0x0000000014a4bc85 5. /build/src/Interpreters/ProcessList.cpp:520: DB::QueryStatus::throwProperExceptionIfNeeded(unsigned long const&, unsigned long const&) @ 0x0000000014a4bbd9 6. /build/src/Interpreters/ProcessList.cpp:557: DB::QueryStatus::checkTimeLimit() @ 0x0000000014a4c2cd 7. /build/src/Processors/Executors/PipelineExecutor.cpp:206: DB::PipelineExecutor::finalizeExecution() @ 0x00000000169b13ba 8. /build/src/Processors/Executors/PipelineExecutor.cpp:153: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x00000000169b0584 9. /build/src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:se190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169bfeab 10. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc3d92 11. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fcca080 12. ? @ 0x00007fbc6213eac3 13. ? @ 0x00007fbc621d0850 Job's origin stack trace: 0. /build/src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000000fc33b84 1. /build/src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000000fcc2ea7 2. /build/src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fcc535c 3. /build/src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000000fcc584d 4. /build/src/Common/ThreadPool.h:279: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x00000000169bf193 5. /build/src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x00000000169bf518 6. /build/src/Server/TCPHandler.cpp:1237: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x00000000168f1525 7. /build/src/Server/TCPHandler.cpp:678: DB::TCPHandler::runImpl() @ 0x00000000168e68e5 8. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 9. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 10. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 11. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 12. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 13. ? @ 0x00007fbc6213eac3 14. ? @ 0x00007fbc621d0850 2025.07.28 12:02:24.174718 [ 5951 ] {12c12652-923a-43ca-91e1-18f68c1176e8} executeQuery: Code: 394. DB::Exception: Query was cancelled. (QUERY_WAS_CANCELLED) (version 25.3.6.10636.altinitytest (altinity build)) (from [::1]:33848) (comment: 02461_cancel_finish_race.sh) (query 1, line 1) (in query: KILL QUERY WHERE current_database = 'test_dtwle8fg' SYNC FORMAT Null), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000000a074fcb 4. /build/src/Interpreters/ProcessList.cpp:567: DB::QueryStatus::throwQueryWasCancelled() const @ 0x0000000014a4bc85 5. /build/src/Interpreters/ProcessList.cpp:520: DB::QueryStatus::throwProperExceptionIfNeeded(unsigned long const&, unsigned long const&) @ 0x0000000014a4bbd9 6. /build/src/Interpreters/ProcessList.cpp:557: DB::QueryStatus::checkTimeLimit() @ 0x0000000014a4c2cd 7. /build/src/Processors/Executors/PipelineExecutor.cpp:206: DB::PipelineExecutor::finalizeExecution() @ 0x00000000169b13ba 8. /build/src/Processors/Executors/PipelineExecutor.cpp:153: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x00000000169b0584 9. /build/src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:se190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169bfeab 10. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc3d92 11. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fcca080 12. ? @ 0x00007fbc6213eac3 13. ? @ 0x00007fbc621d0850 2025.07.28 12:02:24.184357 [ 5951 ] {} TCPHandler: Code: 394. DB::Exception: Query was cancelled. (QUERY_WAS_CANCELLED), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000000a074fcb 4. /build/src/Interpreters/ProcessList.cpp:567: DB::QueryStatus::throwQueryWasCancelled() const @ 0x0000000014a4bc85 5. /build/src/Interpreters/ProcessList.cpp:520: DB::QueryStatus::throwProperExceptionIfNeeded(unsigned long const&, unsigned long const&) @ 0x0000000014a4bbd9 6. /build/src/Interpreters/ProcessList.cpp:557: DB::QueryStatus::checkTimeLimit() @ 0x0000000014a4c2cd 7. /build/src/Processors/Executors/PipelineExecutor.cpp:206: DB::PipelineExecutor::finalizeExecution() @ 0x00000000169b13ba 8. /build/src/Processors/Executors/PipelineExecutor.cpp:153: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x00000000169b0584 9. /build/src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:se190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169bfeab 10. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc3d92 11. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fcca080 12. ? @ 0x00007fbc6213eac3 13. ? @ 0x00007fbc621d0850 Job's origin stack trace: 0. /build/src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000000fc33b84 1. /build/src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000000fcc2ea7 2. /build/src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fcc535c 3. /build/src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000000fcc584d 4. /build/src/Common/ThreadPool.h:279: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x00000000169bf193 5. /build/src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x00000000169bf518 6. /build/src/Server/TCPHandler.cpp:1237: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x00000000168f1525 7. /build/src/Server/TCPHandler.cpp:678: DB::TCPHandler::runImpl() @ 0x00000000168e68e5 8. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 9. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 10. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 11. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 12. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 13. ? @ 0x00007fbc6213eac3 14. ? @ 0x00007fbc621d0850 2025.07.28 12:02:24.428687 [ 62057 ] {64389c4e-6e1b-4878-bd53-432ade26a621} executeQuery: Code: 394. DB::Exception: Query was cancelled. (QUERY_WAS_CANCELLED) (version 25.3.6.10636.altinitytest (altinity build)) (from [::1]:33976) (comment: 02461_cancel_finish_race.sh) (query 1, line 1) (in query: KILL QUERY WHERE current_database = 'test_dtwle8fg' SYNC FORMAT Null), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000000a074fcb 4. /build/src/Interpreters/ProcessList.cpp:567: DB::QueryStatus::throwQueryWasCancelled() const @ 0x0000000014a4bc85 5. /build/src/Interpreters/ProcessList.cpp:520: DB::QueryStatus::throwProperExceptionIfNeeded(unsigned long const&, unsigned long const&) @ 0x0000000014a4bbd9 6. /build/src/Interpreters/ProcessList.cpp:531: DB::QueryStatus::addPipelineExecutor(DB::PipelineExecutor*) @ 0x0000000014a4bd9c 7. /build/src/Processors/Executors/PipelineExecutor.cpp:73: DB::PipelineExecutor::PipelineExecutor(std::shared_ptr, std::allocator>>>&, std::shared_ptr) @ 0x00000000169afe31 8. /build/contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x00000000169bef66 9. /build/src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x00000000169bf518 10. /build/src/Server/TCPHandler.cpp:1237: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x00000000168f1525 11. /build/src/Server/TCPHandler.cpp:678: DB::TCPHandler::runImpl() @ 0x00000000168e68e5 12. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 13. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 14. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 16. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 17. ? @ 0x00007fbc6213eac3 18. ? @ 0x00007fbc621d0850 2025.07.28 12:02:24.429335 [ 62075 ] {961aa25a-2e72-478f-b722-3fd62e6fe543} executeQuery: Code: 394. DB::Exception: Query was cancelled. (QUERY_WAS_CANCELLED) (version 25.3.6.10636.altinitytest (altinity build)) (from [::1]:33954) (comment: 02461_cancel_finish_race.sh) (query 1, line 1) (in query: KILL QUERY WHERE current_database = 'test_dtwle8fg' SYNC FORMAT Null), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000000a074fcb 4. /build/src/Interpreters/ProcessList.cpp:567: DB::QueryStatus::throwQueryWasCancelled() const @ 0x0000000014a4bc85 5. /build/src/Interpreters/ProcessList.cpp:520: DB::QueryStatus::throwProperExceptionIfNeeded(unsigned long const&, unsigned long const&) @ 0x0000000014a4bbd9 6. /build/src/Interpreters/ProcessList.cpp:557: DB::QueryStatus::checkTimeLimit() @ 0x0000000014a4c2cd 7. /build/src/Processors/Executors/PipelineExecutor.cpp:206: DB::PipelineExecutor::finalizeExecution() @ 0x00000000169b13ba 8. /build/src/Processors/Executors/PipelineExecutor.cpp:153: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x00000000169b0584 9. /build/src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:se190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169bfeab 10. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc3d92 11. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fcca080 12. ? @ 0x00007fbc6213eac3 13. ? @ 0x00007fbc621d0850 2025.07.28 12:02:24.442539 [ 62057 ] {} TCPHandler: Code: 394. DB::Exception: Query was cancelled. (QUERY_WAS_CANCELLED), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000000a074fcb 4. /build/src/Interpreters/ProcessList.cpp:567: DB::QueryStatus::throwQueryWasCancelled() const @ 0x0000000014a4bc85 5. /build/src/Interpreters/ProcessList.cpp:520: DB::QueryStatus::throwProperExceptionIfNeeded(unsigned long const&, unsigned long const&) @ 0x0000000014a4bbd9 6. /build/src/Interpreters/ProcessList.cpp:531: DB::QueryStatus::addPipelineExecutor(DB::PipelineExecutor*) @ 0x0000000014a4bd9c 7. /build/src/Processors/Executors/PipelineExecutor.cpp:73: DB::PipelineExecutor::PipelineExecutor(std::shared_ptr, std::allocator>>>&, std::shared_ptr) @ 0x00000000169afe31 8. /build/contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x00000000169bef66 9. /build/src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x00000000169bf518 10. /build/src/Server/TCPHandler.cpp:1237: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x00000000168f1525 11. /build/src/Server/TCPHandler.cpp:678: DB::TCPHandler::runImpl() @ 0x00000000168e68e5 12. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 13. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 14. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 16. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 17. ? @ 0x00007fbc6213eac3 18. ? @ 0x00007fbc621d0850 2025.07.28 12:02:24.443742 [ 62075 ] {} TCPHandler: Code: 394. DB::Exception: Query was cancelled. (QUERY_WAS_CANCELLED), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000000a074fcb 4. /build/src/Interpreters/ProcessList.cpp:567: DB::QueryStatus::throwQueryWasCancelled() const @ 0x0000000014a4bc85 5. /build/src/Interpreters/ProcessList.cpp:520: DB::QueryStatus::throwProperExceptionIfNeeded(unsigned long const&, unsigned long const&) @ 0x0000000014a4bbd9 6. /build/src/Interpreters/ProcessList.cpp:557: DB::QueryStatus::checkTimeLimit() @ 0x0000000014a4c2cd 7. /build/src/Processors/Executors/PipelineExecutor.cpp:206: DB::PipelineExecutor::finalizeExecution() @ 0x00000000169b13ba 8. /build/src/Processors/Executors/PipelineExecutor.cpp:153: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x00000000169b0584 9. /build/src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:se190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169bfeab 10. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc3d92 11. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fcca080 12. ? @ 0x00007fbc6213eac3 13. ? @ 0x00007fbc621d0850 Job's origin stack trace: 0. /build/src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000000fc33b84 1. /build/src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000000fcc2ea7 2. /build/src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fcc535c 3. /build/src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000000fcc584d 4. /build/src/Common/ThreadPool.h:279: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x00000000169bf193 5. /build/src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x00000000169bf518 6. /build/src/Server/TCPHandler.cpp:1237: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x00000000168f1525 7. /build/src/Server/TCPHandler.cpp:678: DB::TCPHandler::runImpl() @ 0x00000000168e68e5 8. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 9. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 10. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 11. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 12. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 13. ? @ 0x00007fbc6213eac3 14. ? @ 0x00007fbc621d0850 2025.07.28 12:02:24.455836 [ 7625 ] {} TCPHandler: Code: 394. DB::Exception: Query was cancelled. (QUERY_WAS_CANCELLED), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000000a074fcb 4. /build/src/Interpreters/ProcessList.cpp:567: DB::QueryStatus::throwQueryWasCancelled() const @ 0x0000000014a4bc85 5. /build/src/Interpreters/ProcessList.cpp:520: DB::QueryStatus::throwProperExceptionIfNeeded(unsigned long const&, unsigned long const&) @ 0x0000000014a4bbd9 6. /build/src/Interpreters/ProcessList.cpp:531: DB::QueryStatus::addPipelineExecutor(DB::PipelineExecutor*) @ 0x0000000014a4bd9c 7. /build/src/Processors/Executors/PipelineExecutor.cpp:73: DB::PipelineExecutor::PipelineExecutor(std::shared_ptr, std::allocator>>>&, std::shared_ptr) @ 0x00000000169afe31 8. /build/contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x00000000169c07b5 9. /build/src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x00000000169c0978 10. /build/src/Interpreters/InterpreterKillQueryQuery.cpp:439: DB::InterpreterKillQueryQuery::getSelectResult(String const&, String const&) @ 0x0000000014cf0f04 11. /build/src/Interpreters/InterpreterKillQueryQuery.cpp:222: DB::InterpreterKillQueryQuery::execute() @ 0x0000000014cebde2 12. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88dc9 13. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 14. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 15. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 16. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 17. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 18. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 19. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 20. ? @ 0x00007fbc6213eac3 21. ? @ 0x00007fbc621d0850 2025.07.28 12:02:24.493040 [ 17611 ] {ddea96d8-e76d-4c0b-a309-4a1608fa3d1d} executeQuery: Code: 394. DB::Exception: Query was cancelled. (QUERY_WAS_CANCELLED) (version 25.3.6.10636.altinitytest (altinity build)) (from [::1]:33938) (comment: 02461_cancel_finish_race.sh) (query 1, line 1) (in query: KILL QUERY WHERE current_database = 'test_dtwle8fg' SYNC FORMAT Null), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000000a074fcb 4. /build/src/Interpreters/ProcessList.cpp:567: DB::QueryStatus::throwQueryWasCancelled() const @ 0x0000000014a4bc85 5. /build/src/Interpreters/ProcessList.cpp:520: DB::QueryStatus::throwProperExceptionIfNeeded(unsigned long const&, unsigned long const&) @ 0x0000000014a4bbd9 6. /build/src/Interpreters/ProcessList.cpp:557: DB::QueryStatus::checkTimeLimit() @ 0x0000000014a4c2cd 7. /build/src/Processors/Executors/PipelineExecutor.cpp:206: DB::PipelineExecutor::finalizeExecution() @ 0x00000000169b13ba 8. /build/src/Processors/Executors/PipelineExecutor.cpp:153: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x00000000169b0584 9. /build/src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:se190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169bfeab 10. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc3d92 11. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fcca080 12. ? @ 0x00007fbc6213eac3 13. ? @ 0x00007fbc621d0850 2025.07.28 12:02:24.493451 [ 62325 ] {} TCPHandler: Code: 394. DB::Exception: Query was cancelled. (QUERY_WAS_CANCELLED), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000000a074fcb 4. /build/src/Interpreters/ProcessList.cpp:567: DB::QueryStatus::throwQueryWasCancelled() const @ 0x0000000014a4bc85 5. /build/src/Interpreters/ProcessList.cpp:520: DB::QueryStatus::throwProperExceptionIfNeeded(unsigned long const&, unsigned long const&) @ 0x0000000014a4bbd9 6. /build/src/Interpreters/ProcessList.cpp:531: DB::QueryStatus::addPipelineExecutor(DB::PipelineExecutor*) @ 0x0000000014a4bd9c 7. /build/src/Processors/Executors/PipelineExecutor.cpp:73: DB::PipelineExecutor::PipelineExecutor(std::shared_ptr, std::allocator>>>&, std::shared_ptr) @ 0x00000000169afe31 8. /build/contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x00000000169c07b5 9. /build/src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x00000000169c0978 10. /build/src/Interpreters/InterpreterKillQueryQuery.cpp:439: DB::InterpreterKillQueryQuery::getSelectResult(String const&, String const&) @ 0x0000000014cf0f04 11. /build/src/Interpreters/InterpreterKillQueryQuery.cpp:222: DB::InterpreterKillQueryQuery::execute() @ 0x0000000014cebde2 12. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88dc9 13. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 14. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 15. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 16. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 17. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 18. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 19. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 20. ? @ 0x00007fbc6213eac3 21. ? @ 0x00007fbc621d0850 2025.07.28 12:02:24.515917 [ 17611 ] {} TCPHandler: Code: 394. DB::Exception: Query was cancelled. (QUERY_WAS_CANCELLED), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000000a074fcb 4. /build/src/Interpreters/ProcessList.cpp:567: DB::QueryStatus::throwQueryWasCancelled() const @ 0x0000000014a4bc85 5. /build/src/Interpreters/ProcessList.cpp:520: DB::QueryStatus::throwProperExceptionIfNeeded(unsigned long const&, unsigned long const&) @ 0x0000000014a4bbd9 6. /build/src/Interpreters/ProcessList.cpp:557: DB::QueryStatus::checkTimeLimit() @ 0x0000000014a4c2cd 7. /build/src/Processors/Executors/PipelineExecutor.cpp:206: DB::PipelineExecutor::finalizeExecution() @ 0x00000000169b13ba 8. /build/src/Processors/Executors/PipelineExecutor.cpp:153: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x00000000169b0584 9. /build/src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:se190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169bfeab 10. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc3d92 11. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fcca080 12. ? @ 0x00007fbc6213eac3 13. ? @ 0x00007fbc621d0850 Job's origin stack trace: 0. /build/src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000000fc33b84 1. /build/src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000000fcc2ea7 2. /build/src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fcc535c 3. /build/src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000000fcc584d 4. /build/src/Common/ThreadPool.h:279: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x00000000169bf193 5. /build/src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x00000000169bf518 6. /build/src/Server/TCPHandler.cpp:1237: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x00000000168f1525 7. /build/src/Server/TCPHandler.cpp:678: DB::TCPHandler::runImpl() @ 0x00000000168e68e5 8. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 9. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 10. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 11. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 12. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 13. ? @ 0x00007fbc6213eac3 14. ? @ 0x00007fbc621d0850 2025.07.28 12:02:24.887683 [ 4900 ] {} TCPHandler: Code: 394. DB::Exception: Query was cancelled. (QUERY_WAS_CANCELLED), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000000a074fcb 4. /build/src/Interpreters/ProcessList.cpp:567: DB::QueryStatus::throwQueryWasCancelled() const @ 0x0000000014a4bc85 5. /build/src/Interpreters/ProcessList.cpp:520: DB::QueryStatus::throwProperExceptionIfNeeded(unsigned long const&, unsigned long const&) @ 0x0000000014a4bbd9 6. /build/src/Interpreters/ProcessList.cpp:557: DB::QueryStatus::checkTimeLimit() @ 0x0000000014a4c2cd 7. /build/src/Processors/Executors/PipelineExecutor.cpp:206: DB::PipelineExecutor::finalizeExecution() @ 0x00000000169b13ba 8. /build/src/Processors/Executors/PipelineExecutor.cpp:181: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x00000000169b1726 9. /build/src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x00000000169c081c 10. /build/src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x00000000169c0978 11. /build/src/Interpreters/InterpreterKillQueryQuery.cpp:439: DB::InterpreterKillQueryQuery::getSelectResult(String const&, String const&) @ 0x0000000014cf0f04 12. /build/src/Interpreters/InterpreterKillQueryQuery.cpp:222: DB::InterpreterKillQueryQuery::execute() @ 0x0000000014cebde2 13. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88dc9 14. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 15. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 16. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 17. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 18. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 19. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 20. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 21. ? @ 0x00007fbc6213eac3 22. ? @ 0x00007fbc621d0850 2025.07.28 12:02:24.899194 [ 5951 ] {} TCPHandler: Code: 394. DB::Exception: Query was cancelled. (QUERY_WAS_CANCELLED), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000000a074fcb 4. /build/src/Interpreters/ProcessList.cpp:567: DB::QueryStatus::throwQueryWasCancelled() const @ 0x0000000014a4bc85 5. /build/src/Interpreters/ProcessList.cpp:520: DB::QueryStatus::throwProperExceptionIfNeeded(unsigned long const&, unsigned long const&) @ 0x0000000014a4bbd9 6. /build/src/Interpreters/ProcessList.cpp:531: DB::QueryStatus::addPipelineExecutor(DB::PipelineExecutor*) @ 0x0000000014a4bd9c 7. /build/src/Processors/Executors/PipelineExecutor.cpp:73: DB::PipelineExecutor::PipelineExecutor(std::shared_ptr, std::allocator>>>&, std::shared_ptr) @ 0x00000000169afe31 8. /build/contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x00000000169c07b5 9. /build/src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x00000000169c0978 10. /build/src/Interpreters/InterpreterKillQueryQuery.cpp:439: DB::InterpreterKillQueryQuery::getSelectResult(String const&, String const&) @ 0x0000000014cf0f04 11. /build/src/Interpreters/InterpreterKillQueryQuery.cpp:222: DB::InterpreterKillQueryQuery::execute() @ 0x0000000014cebde2 12. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88dc9 13. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 14. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 15. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 16. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 17. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 18. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 19. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 20. ? @ 0x00007fbc6213eac3 21. ? @ 0x00007fbc621d0850 2025.07.28 12:02:24.958231 [ 62075 ] {07514a66-ec4b-462b-b623-63dfdf174691} executeQuery: Code: 394. DB::Exception: Query was cancelled. (QUERY_WAS_CANCELLED) (version 25.3.6.10636.altinitytest (altinity build)) (from [::1]:34122) (comment: 02461_cancel_finish_race.sh) (query 1, line 1) (in query: KILL QUERY WHERE current_database = 'test_dtwle8fg' SYNC FORMAT Null), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000000a074fcb 4. /build/src/Interpreters/ProcessList.cpp:567: DB::QueryStatus::throwQueryWasCancelled() const @ 0x0000000014a4bc85 5. /build/src/Interpreters/ProcessList.cpp:520: DB::QueryStatus::throwProperExceptionIfNeeded(unsigned long const&, unsigned long const&) @ 0x0000000014a4bbd9 6. /build/src/Interpreters/ProcessList.cpp:557: DB::QueryStatus::checkTimeLimit() @ 0x0000000014a4c2cd 7. /build/src/Processors/Executors/PipelineExecutor.cpp:206: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x00000000169b03a3 8. /build/src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:se190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169bfeab 9. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc3d92 10. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fcca080 11. ? @ 0x00007fbc6213eac3 12. ? @ 0x00007fbc621d0850 2025.07.28 12:02:24.969031 [ 3977 ] {} test_13.rmt2 (7f9b740d-015c-470e-8cc6-8ba33be0dc63): auto DB::StorageReplicatedMergeTree::processQueueEntry(ReplicatedMergeTreeQueue::SelectedEntryPtr)::(anonymous class)::operator()(LogEntryPtr &) const: Code: 86. DB::HTTPException: Received error from remote server http://146b4357c08d:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Ftest%2F01165%2Ftest_13%2Frmt%2Freplicas%2F1&part=20250728_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.6.10636.altinitytest (altinity build)) '. (RECEIVED_ERROR_FROM_REMOTE_IO_SERVER), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.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 const&, int&&, String const&, unsigned long&&, String const&) @ 0x000000000feda8d9 4. /build/src/IO/HTTPCommon.cpp:104: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x000000000feda6e2 5. /build/src/IO/HTTPCommon.cpp:93: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x000000000feda537 6. /build/src/IO/ReadWriteBufferFromHTTP.cpp:277: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x000000001184a4c4 7. /build/src/IO/ReadWriteBufferFromHTTP.cpp:285: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x000000001184a615 8. /build/src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x000000001184ae59 9. /build/src/IO/ReadWriteBufferFromHTTP.cpp:472: void std::__function::__policy_invoker::__call_impl[abi:se190107]>(std::__function::__policy_storage const*) @ 0x000000001184cedd 10. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001184858b 11. /build/src/IO/ReadWriteBufferFromHTTP.cpp:465: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x000000001184bf0b 12. /build/src/IO/ReadBuffer.h:60: DB::ReadBuffer::next() @ 0x000000000a148c7b 13. /build/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) @ 0x0000000011849fb2 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]>&)>&, 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&) @ 0x0000000011841980 15. /build/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) @ 0x000000001621208e 16. /build/src/Storages/StorageReplicatedMergeTree.cpp:5228: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl[abi:se190107] const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000015f9a5fe 17. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000015ed8bfd 18. /build/src/Storages/StorageReplicatedMergeTree.cpp:2514: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x0000000015ec9aab 19. /build/src/Storages/StorageReplicatedMergeTree.cpp:2349: DB::StorageReplicatedMergeTree::executeLogEntry(DB::ReplicatedMergeTreeLogEntry&) @ 0x0000000015eba91b 20. /build/src/Storages/StorageReplicatedMergeTree.cpp:3876: bool std::__function::__policy_invoker&)>::__call_impl[abi:se190107])::$_1, bool (std::shared_ptr&)>>(std::__function::__policy_storage const*, std::shared_ptr&) @ 0x0000000015f9837e 21. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000165d6fc3 22. /build/src/Storages/StorageReplicatedMergeTree.cpp:3872: DB::StorageReplicatedMergeTree::processQueueEntry(std::shared_ptr) @ 0x0000000015efc18a 23. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001624c1b2 24. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000162f9c70 25. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x00000000162fa55a 26. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc6653 27. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000000fccc4c3 28. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc3d92 29. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fcca080 30. ? @ 0x00007fbc6213eac3 31. ? @ 0x00007fbc621d0850 (version 25.3.6.10636.altinitytest (altinity build)) 2025.07.28 12:02:24.994369 [ 62075 ] {} TCPHandler: Code: 394. DB::Exception: Query was cancelled. (QUERY_WAS_CANCELLED), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000000a074fcb 4. /build/src/Interpreters/ProcessList.cpp:567: DB::QueryStatus::throwQueryWasCancelled() const @ 0x0000000014a4bc85 5. /build/src/Interpreters/ProcessList.cpp:520: DB::QueryStatus::throwProperExceptionIfNeeded(unsigned long const&, unsigned long const&) @ 0x0000000014a4bbd9 6. /build/src/Interpreters/ProcessList.cpp:557: DB::QueryStatus::checkTimeLimit() @ 0x0000000014a4c2cd 7. /build/src/Processors/Executors/PipelineExecutor.cpp:206: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x00000000169b03a3 8. /build/src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:se190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169bfeab 9. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc3d92 10. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fcca080 11. ? @ 0x00007fbc6213eac3 12. ? @ 0x00007fbc621d0850 Job's origin stack trace: 0. /build/src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000000fc33b84 1. /build/src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000000fcc2ea7 2. /build/src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fcc535c 3. /build/src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000000fcc584d 4. /build/src/Common/ThreadPool.h:279: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x00000000169bf193 5. /build/src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x00000000169bf518 6. /build/src/Server/TCPHandler.cpp:1237: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x00000000168f1525 7. /build/src/Server/TCPHandler.cpp:678: DB::TCPHandler::runImpl() @ 0x00000000168e68e5 8. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 9. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 10. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 11. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 12. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 13. ? @ 0x00007fbc6213eac3 14. ? @ 0x00007fbc621d0850 2025.07.28 12:02:25.010508 [ 17252 ] {} TCPHandler: Code: 394. DB::Exception: Query was cancelled. (QUERY_WAS_CANCELLED), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000000a074fcb 4. /build/src/Interpreters/ProcessList.cpp:567: DB::QueryStatus::throwQueryWasCancelled() const @ 0x0000000014a4bc85 5. /build/src/Interpreters/ProcessList.cpp:520: DB::QueryStatus::throwProperExceptionIfNeeded(unsigned long const&, unsigned long const&) @ 0x0000000014a4bbd9 6. /build/src/Interpreters/ProcessList.cpp:531: DB::QueryStatus::addPipelineExecutor(DB::PipelineExecutor*) @ 0x0000000014a4bd9c 7. /build/src/Processors/Executors/PipelineExecutor.cpp:73: DB::PipelineExecutor::PipelineExecutor(std::shared_ptr, std::allocator>>>&, std::shared_ptr) @ 0x00000000169afe31 8. /build/contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x00000000169c07b5 9. /build/src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x00000000169c0978 10. /build/src/Interpreters/InterpreterKillQueryQuery.cpp:439: DB::InterpreterKillQueryQuery::getSelectResult(String const&, String const&) @ 0x0000000014cf0f04 11. /build/src/Interpreters/InterpreterKillQueryQuery.cpp:222: DB::InterpreterKillQueryQuery::execute() @ 0x0000000014cebde2 12. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88dc9 13. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 14. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 15. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 16. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 17. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 18. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 19. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 20. ? @ 0x00007fbc6213eac3 21. ? @ 0x00007fbc621d0850 2025.07.28 12:02:25.022198 [ 62056 ] {} TCPHandler: Code: 394. DB::Exception: Query was cancelled. (QUERY_WAS_CANCELLED), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000000a074fcb 4. /build/src/Interpreters/ProcessList.cpp:567: DB::QueryStatus::throwQueryWasCancelled() const @ 0x0000000014a4bc85 5. /build/src/Interpreters/ProcessList.cpp:520: DB::QueryStatus::throwProperExceptionIfNeeded(unsigned long const&, unsigned long const&) @ 0x0000000014a4bbd9 6. /build/src/Interpreters/ProcessList.cpp:531: DB::QueryStatus::addPipelineExecutor(DB::PipelineExecutor*) @ 0x0000000014a4bd9c 7. /build/src/Processors/Executors/PipelineExecutor.cpp:73: DB::PipelineExecutor::PipelineExecutor(std::shared_ptr, std::allocator>>>&, std::shared_ptr) @ 0x00000000169afe31 8. /build/contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x00000000169c07b5 9. /build/src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x00000000169c0978 10. /build/src/Interpreters/InterpreterKillQueryQuery.cpp:439: DB::InterpreterKillQueryQuery::getSelectResult(String const&, String const&) @ 0x0000000014cf0f04 11. /build/src/Interpreters/InterpreterKillQueryQuery.cpp:222: DB::InterpreterKillQueryQuery::execute() @ 0x0000000014cebde2 12. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88dc9 13. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 14. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 15. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 16. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 17. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 18. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 19. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 20. ? @ 0x00007fbc6213eac3 21. ? @ 0x00007fbc621d0850 2025.07.28 12:02:25.122867 [ 62053 ] {2ca196c2-97bd-47d3-96d9-e352670569ba} executeQuery: Code: 394. DB::Exception: Query was cancelled. (QUERY_WAS_CANCELLED) (version 25.3.6.10636.altinitytest (altinity build)) (from [::1]:34142) (comment: 02461_cancel_finish_race.sh) (query 1, line 1) (in query: KILL QUERY WHERE current_database = 'test_dtwle8fg' SYNC FORMAT Null), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000000a074fcb 4. /build/src/Interpreters/ProcessList.cpp:567: DB::QueryStatus::throwQueryWasCancelled() const @ 0x0000000014a4bc85 5. /build/src/Interpreters/ProcessList.cpp:520: DB::QueryStatus::throwProperExceptionIfNeeded(unsigned long const&, unsigned long const&) @ 0x0000000014a4bbd9 6. /build/src/Interpreters/ProcessList.cpp:531: DB::QueryStatus::addPipelineExecutor(DB::PipelineExecutor*) @ 0x0000000014a4bd9c 7. /build/src/Processors/Executors/PipelineExecutor.cpp:73: DB::PipelineExecutor::PipelineExecutor(std::shared_ptr, std::allocator>>>&, std::shared_ptr) @ 0x00000000169afe31 8. /build/contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x00000000169bef66 9. /build/src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x00000000169bf518 10. /build/src/Server/TCPHandler.cpp:1237: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x00000000168f1525 11. /build/src/Server/TCPHandler.cpp:678: DB::TCPHandler::runImpl() @ 0x00000000168e68e5 12. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 13. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 14. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 16. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 17. ? @ 0x00007fbc6213eac3 18. ? @ 0x00007fbc621d0850 2025.07.28 12:02:25.136903 [ 62053 ] {} TCPHandler: Code: 394. DB::Exception: Query was cancelled. (QUERY_WAS_CANCELLED), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000000a074fcb 4. /build/src/Interpreters/ProcessList.cpp:567: DB::QueryStatus::throwQueryWasCancelled() const @ 0x0000000014a4bc85 5. /build/src/Interpreters/ProcessList.cpp:520: DB::QueryStatus::throwProperExceptionIfNeeded(unsigned long const&, unsigned long const&) @ 0x0000000014a4bbd9 6. /build/src/Interpreters/ProcessList.cpp:531: DB::QueryStatus::addPipelineExecutor(DB::PipelineExecutor*) @ 0x0000000014a4bd9c 7. /build/src/Processors/Executors/PipelineExecutor.cpp:73: DB::PipelineExecutor::PipelineExecutor(std::shared_ptr, std::allocator>>>&, std::shared_ptr) @ 0x00000000169afe31 8. /build/contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x00000000169bef66 9. /build/src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x00000000169bf518 10. /build/src/Server/TCPHandler.cpp:1237: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x00000000168f1525 11. /build/src/Server/TCPHandler.cpp:678: DB::TCPHandler::runImpl() @ 0x00000000168e68e5 12. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 13. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 14. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 16. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 17. ? @ 0x00007fbc6213eac3 18. ? @ 0x00007fbc621d0850 2025.07.28 12:02:25.167452 [ 62058 ] {} TCPHandler: Code: 394. DB::Exception: Query was cancelled. (QUERY_WAS_CANCELLED), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000000a074fcb 4. /build/src/Interpreters/ProcessList.cpp:567: DB::QueryStatus::throwQueryWasCancelled() const @ 0x0000000014a4bc85 5. /build/src/Interpreters/ProcessList.cpp:520: DB::QueryStatus::throwProperExceptionIfNeeded(unsigned long const&, unsigned long const&) @ 0x0000000014a4bbd9 6. /build/src/Interpreters/ProcessList.cpp:531: DB::QueryStatus::addPipelineExecutor(DB::PipelineExecutor*) @ 0x0000000014a4bd9c 7. /build/src/Processors/Executors/PipelineExecutor.cpp:73: DB::PipelineExecutor::PipelineExecutor(std::shared_ptr, std::allocator>>>&, std::shared_ptr) @ 0x00000000169afe31 8. /build/contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x00000000169c07b5 9. /build/src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x00000000169c0978 10. /build/src/Interpreters/InterpreterKillQueryQuery.cpp:439: DB::InterpreterKillQueryQuery::getSelectResult(String const&, String const&) @ 0x0000000014cf0f04 11. /build/src/Interpreters/InterpreterKillQueryQuery.cpp:222: DB::InterpreterKillQueryQuery::execute() @ 0x0000000014cebde2 12. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88dc9 13. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 14. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 15. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 16. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 17. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 18. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 19. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 20. ? @ 0x00007fbc6213eac3 21. ? @ 0x00007fbc621d0850 2025.07.28 12:02:25.190224 [ 5112 ] {f208adf8-ec48-4a40-a747-3f5700c2c312} executeQuery: Code: 394. DB::Exception: Query was cancelled. (QUERY_WAS_CANCELLED) (version 25.3.6.10636.altinitytest (altinity build)) (from [::1]:34116) (comment: 02461_cancel_finish_race.sh) (query 1, line 1) (in query: KILL QUERY WHERE current_database = 'test_dtwle8fg' SYNC FORMAT Null), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000000a074fcb 4. /build/src/Interpreters/ProcessList.cpp:567: DB::QueryStatus::throwQueryWasCancelled() const @ 0x0000000014a4bc85 5. /build/src/Interpreters/ProcessList.cpp:520: DB::QueryStatus::throwProperExceptionIfNeeded(unsigned long const&, unsigned long const&) @ 0x0000000014a4bbd9 6. /build/src/Interpreters/ProcessList.cpp:557: DB::QueryStatus::checkTimeLimit() @ 0x0000000014a4c2cd 7. /build/src/Processors/Executors/PipelineExecutor.cpp:206: DB::PipelineExecutor::finalizeExecution() @ 0x00000000169b13ba 8. /build/src/Processors/Executors/PipelineExecutor.cpp:153: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x00000000169b0584 9. /build/src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:se190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169bfeab 10. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc3d92 11. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fcca080 12. ? @ 0x00007fbc6213eac3 13. ? @ 0x00007fbc621d0850 2025.07.28 12:02:25.200576 [ 5112 ] {} TCPHandler: Code: 394. DB::Exception: Query was cancelled. (QUERY_WAS_CANCELLED), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000000a074fcb 4. /build/src/Interpreters/ProcessList.cpp:567: DB::QueryStatus::throwQueryWasCancelled() const @ 0x0000000014a4bc85 5. /build/src/Interpreters/ProcessList.cpp:520: DB::QueryStatus::throwProperExceptionIfNeeded(unsigned long const&, unsigned long const&) @ 0x0000000014a4bbd9 6. /build/src/Interpreters/ProcessList.cpp:557: DB::QueryStatus::checkTimeLimit() @ 0x0000000014a4c2cd 7. /build/src/Processors/Executors/PipelineExecutor.cpp:206: DB::PipelineExecutor::finalizeExecution() @ 0x00000000169b13ba 8. /build/src/Processors/Executors/PipelineExecutor.cpp:153: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x00000000169b0584 9. /build/src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:se190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169bfeab 10. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc3d92 11. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fcca080 12. ? @ 0x00007fbc6213eac3 13. ? @ 0x00007fbc621d0850 Job's origin stack trace: 0. /build/src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000000fc33b84 1. /build/src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000000fcc2ea7 2. /build/src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fcc535c 3. /build/src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000000fcc584d 4. /build/src/Common/ThreadPool.h:279: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x00000000169bf193 5. /build/src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x00000000169bf518 6. /build/src/Server/TCPHandler.cpp:1237: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x00000000168f1525 7. /build/src/Server/TCPHandler.cpp:678: DB::TCPHandler::runImpl() @ 0x00000000168e68e5 8. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 9. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 10. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 11. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 12. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 13. ? @ 0x00007fbc6213eac3 14. ? @ 0x00007fbc621d0850 2025.07.28 12:02:25.246391 [ 4963 ] {875105b9-a100-41e1-a08d-7376731beca9} executeQuery: Code: 394. DB::Exception: Query was cancelled. (QUERY_WAS_CANCELLED) (version 25.3.6.10636.altinitytest (altinity build)) (from [::1]:34126) (comment: 02461_cancel_finish_race.sh) (query 1, line 1) (in query: KILL QUERY WHERE current_database = 'test_dtwle8fg' SYNC FORMAT Null), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000000a074fcb 4. /build/src/Interpreters/ProcessList.cpp:567: DB::QueryStatus::throwQueryWasCancelled() const @ 0x0000000014a4bc85 5. /build/src/Interpreters/ProcessList.cpp:520: DB::QueryStatus::throwProperExceptionIfNeeded(unsigned long const&, unsigned long const&) @ 0x0000000014a4bbd9 6. /build/src/Interpreters/ProcessList.cpp:557: DB::QueryStatus::checkTimeLimit() @ 0x0000000014a4c2cd 7. /build/src/Processors/Executors/PipelineExecutor.cpp:206: DB::PipelineExecutor::finalizeExecution() @ 0x00000000169b13ba 8. /build/src/Processors/Executors/PipelineExecutor.cpp:153: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x00000000169b0584 9. /build/src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:se190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169bfeab 10. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc3d92 11. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fcca080 12. ? @ 0x00007fbc6213eac3 13. ? @ 0x00007fbc621d0850 2025.07.28 12:02:25.259600 [ 4963 ] {} TCPHandler: Code: 394. DB::Exception: Query was cancelled. (QUERY_WAS_CANCELLED), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000000a074fcb 4. /build/src/Interpreters/ProcessList.cpp:567: DB::QueryStatus::throwQueryWasCancelled() const @ 0x0000000014a4bc85 5. /build/src/Interpreters/ProcessList.cpp:520: DB::QueryStatus::throwProperExceptionIfNeeded(unsigned long const&, unsigned long const&) @ 0x0000000014a4bbd9 6. /build/src/Interpreters/ProcessList.cpp:557: DB::QueryStatus::checkTimeLimit() @ 0x0000000014a4c2cd 7. /build/src/Processors/Executors/PipelineExecutor.cpp:206: DB::PipelineExecutor::finalizeExecution() @ 0x00000000169b13ba 8. /build/src/Processors/Executors/PipelineExecutor.cpp:153: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x00000000169b0584 9. /build/src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:se190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169bfeab 10. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc3d92 11. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fcca080 12. ? @ 0x00007fbc6213eac3 13. ? @ 0x00007fbc621d0850 Job's origin stack trace: 0. /build/src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000000fc33b84 1. /build/src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000000fcc2ea7 2. /build/src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fcc535c 3. /build/src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000000fcc584d 4. /build/src/Common/ThreadPool.h:279: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x00000000169bf193 5. /build/src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x00000000169bf518 6. /build/src/Server/TCPHandler.cpp:1237: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x00000000168f1525 7. /build/src/Server/TCPHandler.cpp:678: DB::TCPHandler::runImpl() @ 0x00000000168e68e5 8. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 9. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 10. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 11. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 12. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 13. ? @ 0x00007fbc6213eac3 14. ? @ 0x00007fbc621d0850 2025.07.28 12:02:25.286661 [ 17256 ] {f9578e34-0fb1-44f8-adbf-b70b21c05e62} executeQuery: Code: 394. DB::Exception: Query was cancelled. (QUERY_WAS_CANCELLED) (version 25.3.6.10636.altinitytest (altinity build)) (from [::1]:34184) (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. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000000a074fcb 4. /build/src/Interpreters/ProcessList.cpp:567: DB::QueryStatus::throwQueryWasCancelled() const @ 0x0000000014a4bc85 5. /build/src/Interpreters/ProcessList.cpp:520: DB::QueryStatus::throwProperExceptionIfNeeded(unsigned long const&, unsigned long const&) @ 0x0000000014a4bbd9 6. /build/src/Interpreters/ProcessList.cpp:557: DB::QueryStatus::checkTimeLimit() @ 0x0000000014a4c2cd 7. /build/src/Processors/Executors/PipelineExecutor.cpp:206: DB::PipelineExecutor::finalizeExecution() @ 0x00000000169b13ba 8. /build/src/Processors/Executors/PipelineExecutor.cpp:153: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x00000000169b0584 9. /build/src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:se190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169bfeab 10. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc3d92 11. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fcca080 12. ? @ 0x00007fbc6213eac3 13. ? @ 0x00007fbc621d0850 2025.07.28 12:02:25.299034 [ 17256 ] {} TCPHandler: Code: 394. DB::Exception: Query was cancelled. (QUERY_WAS_CANCELLED), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000000a074fcb 4. /build/src/Interpreters/ProcessList.cpp:567: DB::QueryStatus::throwQueryWasCancelled() const @ 0x0000000014a4bc85 5. /build/src/Interpreters/ProcessList.cpp:520: DB::QueryStatus::throwProperExceptionIfNeeded(unsigned long const&, unsigned long const&) @ 0x0000000014a4bbd9 6. /build/src/Interpreters/ProcessList.cpp:557: DB::QueryStatus::checkTimeLimit() @ 0x0000000014a4c2cd 7. /build/src/Processors/Executors/PipelineExecutor.cpp:206: DB::PipelineExecutor::finalizeExecution() @ 0x00000000169b13ba 8. /build/src/Processors/Executors/PipelineExecutor.cpp:153: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x00000000169b0584 9. /build/src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:se190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169bfeab 10. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc3d92 11. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fcca080 12. ? @ 0x00007fbc6213eac3 13. ? @ 0x00007fbc621d0850 Job's origin stack trace: 0. /build/src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000000fc33b84 1. /build/src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000000fcc2ea7 2. /build/src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fcc535c 3. /build/src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000000fcc584d 4. /build/src/Common/ThreadPool.h:279: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x00000000169bf193 5. /build/src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x00000000169bf518 6. /build/src/Server/TCPHandler.cpp:1237: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x00000000168f1525 7. /build/src/Server/TCPHandler.cpp:678: DB::TCPHandler::runImpl() @ 0x00000000168e68e5 8. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 9. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 10. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 11. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 12. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 13. ? @ 0x00007fbc6213eac3 14. ? @ 0x00007fbc621d0850 2025.07.28 12:02:25.401926 [ 62325 ] {} TCPHandler: Code: 394. DB::Exception: Query was cancelled. (QUERY_WAS_CANCELLED), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000000a074fcb 4. /build/src/Interpreters/ProcessList.cpp:567: DB::QueryStatus::throwQueryWasCancelled() const @ 0x0000000014a4bc85 5. /build/src/Interpreters/ProcessList.cpp:520: DB::QueryStatus::throwProperExceptionIfNeeded(unsigned long const&, unsigned long const&) @ 0x0000000014a4bbd9 6. /build/src/Interpreters/ProcessList.cpp:531: DB::QueryStatus::addPipelineExecutor(DB::PipelineExecutor*) @ 0x0000000014a4bd9c 7. /build/src/Processors/Executors/PipelineExecutor.cpp:73: DB::PipelineExecutor::PipelineExecutor(std::shared_ptr, std::allocator>>>&, std::shared_ptr) @ 0x00000000169afe31 8. /build/contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x00000000169c07b5 9. /build/src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x00000000169c0978 10. /build/src/Interpreters/InterpreterKillQueryQuery.cpp:439: DB::InterpreterKillQueryQuery::getSelectResult(String const&, String const&) @ 0x0000000014cf0f04 11. /build/src/Interpreters/InterpreterKillQueryQuery.cpp:222: DB::InterpreterKillQueryQuery::execute() @ 0x0000000014cebde2 12. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88dc9 13. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 14. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 15. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 16. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 17. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 18. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 19. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 20. ? @ 0x00007fbc6213eac3 21. ? @ 0x00007fbc621d0850 2025.07.28 12:02:25.488423 [ 11826 ] {623c176e-aa8e-48df-95f6-31481516f933} executeQuery: Code: 394. DB::Exception: Query was cancelled. (QUERY_WAS_CANCELLED) (version 25.3.6.10636.altinitytest (altinity build)) (from [::1]:34262) (comment: 02461_cancel_finish_race.sh) (query 1, line 1) (in query: KILL QUERY WHERE current_database = 'test_dtwle8fg' SYNC FORMAT Null), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000000a074fcb 4. /build/src/Interpreters/ProcessList.cpp:567: DB::QueryStatus::throwQueryWasCancelled() const @ 0x0000000014a4bc85 5. /build/src/Interpreters/ProcessList.cpp:520: DB::QueryStatus::throwProperExceptionIfNeeded(unsigned long const&, unsigned long const&) @ 0x0000000014a4bbd9 6. /build/src/Interpreters/ProcessList.cpp:557: DB::QueryStatus::checkTimeLimit() @ 0x0000000014a4c2cd 7. /build/src/Processors/Executors/PipelineExecutor.cpp:206: DB::PipelineExecutor::finalizeExecution() @ 0x00000000169b13ba 8. /build/src/Processors/Executors/PipelineExecutor.cpp:153: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x00000000169b0584 9. /build/src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:se190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169bfeab 10. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc3d92 11. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fcca080 12. ? @ 0x00007fbc6213eac3 13. ? @ 0x00007fbc621d0850 2025.07.28 12:02:25.505033 [ 11826 ] {} TCPHandler: Code: 394. DB::Exception: Query was cancelled. (QUERY_WAS_CANCELLED), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000000a074fcb 4. /build/src/Interpreters/ProcessList.cpp:567: DB::QueryStatus::throwQueryWasCancelled() const @ 0x0000000014a4bc85 5. /build/src/Interpreters/ProcessList.cpp:520: DB::QueryStatus::throwProperExceptionIfNeeded(unsigned long const&, unsigned long const&) @ 0x0000000014a4bbd9 6. /build/src/Interpreters/ProcessList.cpp:557: DB::QueryStatus::checkTimeLimit() @ 0x0000000014a4c2cd 7. /build/src/Processors/Executors/PipelineExecutor.cpp:206: DB::PipelineExecutor::finalizeExecution() @ 0x00000000169b13ba 8. /build/src/Processors/Executors/PipelineExecutor.cpp:153: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x00000000169b0584 9. /build/src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:se190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169bfeab 10. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc3d92 11. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fcca080 12. ? @ 0x00007fbc6213eac3 13. ? @ 0x00007fbc621d0850 Job's origin stack trace: 0. /build/src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000000fc33b84 1. /build/src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000000fcc2ea7 2. /build/src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fcc535c 3. /build/src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000000fcc584d 4. /build/src/Common/ThreadPool.h:279: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x00000000169bf193 5. /build/src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x00000000169bf518 6. /build/src/Server/TCPHandler.cpp:1237: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x00000000168f1525 7. /build/src/Server/TCPHandler.cpp:678: DB::TCPHandler::runImpl() @ 0x00000000168e68e5 8. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 9. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 10. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 11. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 12. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 13. ? @ 0x00007fbc6213eac3 14. ? @ 0x00007fbc621d0850 2025.07.28 12:02:25.533954 [ 3969 ] {} test_13.rmt2 (7f9b740d-015c-470e-8cc6-8ba33be0dc63): auto DB::StorageReplicatedMergeTree::processQueueEntry(ReplicatedMergeTreeQueue::SelectedEntryPtr)::(anonymous class)::operator()(LogEntryPtr &) const: Code: 86. DB::HTTPException: Received error from remote server http://146b4357c08d:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Ftest%2F01165%2Ftest_13%2Frmt%2Freplicas%2F1&part=20250728_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.6.10636.altinitytest (altinity build)) '. (RECEIVED_ERROR_FROM_REMOTE_IO_SERVER), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.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 const&, int&&, String const&, unsigned long&&, String const&) @ 0x000000000feda8d9 4. /build/src/IO/HTTPCommon.cpp:104: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x000000000feda6e2 5. /build/src/IO/HTTPCommon.cpp:93: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x000000000feda537 6. /build/src/IO/ReadWriteBufferFromHTTP.cpp:277: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x000000001184a4c4 7. /build/src/IO/ReadWriteBufferFromHTTP.cpp:285: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x000000001184a615 8. /build/src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x000000001184ae59 9. /build/src/IO/ReadWriteBufferFromHTTP.cpp:472: void std::__function::__policy_invoker::__call_impl[abi:se190107]>(std::__function::__policy_storage const*) @ 0x000000001184cedd 10. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001184858b 11. /build/src/IO/ReadWriteBufferFromHTTP.cpp:465: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x000000001184bf0b 12. /build/src/IO/ReadBuffer.h:60: DB::ReadBuffer::next() @ 0x000000000a148c7b 13. /build/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) @ 0x0000000011849fb2 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]>&)>&, 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&) @ 0x0000000011841980 15. /build/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) @ 0x000000001621208e 16. /build/src/Storages/StorageReplicatedMergeTree.cpp:5228: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl[abi:se190107] const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000015f9a5fe 17. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000015ed8bfd 18. /build/src/Storages/StorageReplicatedMergeTree.cpp:2514: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x0000000015ec9aab 19. /build/src/Storages/StorageReplicatedMergeTree.cpp:2349: DB::StorageReplicatedMergeTree::executeLogEntry(DB::ReplicatedMergeTreeLogEntry&) @ 0x0000000015eba91b 20. /build/src/Storages/StorageReplicatedMergeTree.cpp:3876: bool std::__function::__policy_invoker&)>::__call_impl[abi:se190107])::$_1, bool (std::shared_ptr&)>>(std::__function::__policy_storage const*, std::shared_ptr&) @ 0x0000000015f9837e 21. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000165d6fc3 22. /build/src/Storages/StorageReplicatedMergeTree.cpp:3872: DB::StorageReplicatedMergeTree::processQueueEntry(std::shared_ptr) @ 0x0000000015efc18a 23. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001624c1b2 24. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000162f9c70 25. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x00000000162fa55a 26. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc6653 27. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000000fccc4c3 28. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc3d92 29. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fcca080 30. ? @ 0x00007fbc6213eac3 31. ? @ 0x00007fbc621d0850 (version 25.3.6.10636.altinitytest (altinity build)) 2025.07.28 12:02:25.561314 [ 17243 ] {} TCPHandler: Code: 394. DB::Exception: Query was cancelled. (QUERY_WAS_CANCELLED), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000000a074fcb 4. /build/src/Interpreters/ProcessList.cpp:567: DB::QueryStatus::throwQueryWasCancelled() const @ 0x0000000014a4bc85 5. /build/src/Interpreters/ProcessList.cpp:520: DB::QueryStatus::throwProperExceptionIfNeeded(unsigned long const&, unsigned long const&) @ 0x0000000014a4bbd9 6. /build/src/Interpreters/ProcessList.cpp:557: DB::QueryStatus::checkTimeLimit() @ 0x0000000014a4c2cd 7. /build/src/Processors/Executors/PipelineExecutor.cpp:206: DB::PipelineExecutor::finalizeExecution() @ 0x00000000169b13ba 8. /build/src/Processors/Executors/PipelineExecutor.cpp:181: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x00000000169b1726 9. /build/src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x00000000169c081c 10. /build/src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x00000000169c0978 11. /build/src/Interpreters/InterpreterKillQueryQuery.cpp:442: DB::InterpreterKillQueryQuery::getSelectResult(String const&, String const&) @ 0x0000000014cf0f6b 12. /build/src/Interpreters/InterpreterKillQueryQuery.cpp:222: DB::InterpreterKillQueryQuery::execute() @ 0x0000000014cebde2 13. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88dc9 14. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 15. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 16. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 17. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 18. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 19. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 20. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 21. ? @ 0x00007fbc6213eac3 22. ? @ 0x00007fbc621d0850 2025.07.28 12:02:25.587863 [ 62056 ] {0d71e297-29f3-41dd-82e5-ea1eed866f41} executeQuery: Code: 394. DB::Exception: Query was cancelled. (QUERY_WAS_CANCELLED) (version 25.3.6.10636.altinitytest (altinity build)) (from [::1]:34260) (comment: 02461_cancel_finish_race.sh) (query 1, line 1) (in query: KILL QUERY WHERE current_database = 'test_dtwle8fg' SYNC FORMAT Null), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000000a074fcb 4. /build/src/Interpreters/ProcessList.cpp:567: DB::QueryStatus::throwQueryWasCancelled() const @ 0x0000000014a4bc85 5. /build/src/Interpreters/ProcessList.cpp:520: DB::QueryStatus::throwProperExceptionIfNeeded(unsigned long const&, unsigned long const&) @ 0x0000000014a4bbd9 6. /build/src/Interpreters/ProcessList.cpp:557: DB::QueryStatus::checkTimeLimit() @ 0x0000000014a4c2cd 7. /build/src/Processors/Executors/PipelineExecutor.cpp:206: DB::PipelineExecutor::finalizeExecution() @ 0x00000000169b13ba 8. /build/src/Processors/Executors/PipelineExecutor.cpp:153: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x00000000169b0584 9. /build/src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:se190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169bfeab 10. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc3d92 11. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fcca080 12. ? @ 0x00007fbc6213eac3 13. ? @ 0x00007fbc621d0850 2025.07.28 12:02:25.608887 [ 62056 ] {} TCPHandler: Code: 394. DB::Exception: Query was cancelled. (QUERY_WAS_CANCELLED), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000000a074fcb 4. /build/src/Interpreters/ProcessList.cpp:567: DB::QueryStatus::throwQueryWasCancelled() const @ 0x0000000014a4bc85 5. /build/src/Interpreters/ProcessList.cpp:520: DB::QueryStatus::throwProperExceptionIfNeeded(unsigned long const&, unsigned long const&) @ 0x0000000014a4bbd9 6. /build/src/Interpreters/ProcessList.cpp:557: DB::QueryStatus::checkTimeLimit() @ 0x0000000014a4c2cd 7. /build/src/Processors/Executors/PipelineExecutor.cpp:206: DB::PipelineExecutor::finalizeExecution() @ 0x00000000169b13ba 8. /build/src/Processors/Executors/PipelineExecutor.cpp:153: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x00000000169b0584 9. /build/src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:se190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169bfeab 10. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc3d92 11. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fcca080 12. ? @ 0x00007fbc6213eac3 13. ? @ 0x00007fbc621d0850 Job's origin stack trace: 0. /build/src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000000fc33b84 1. /build/src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000000fcc2ea7 2. /build/src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fcc535c 3. /build/src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000000fcc584d 4. /build/src/Common/ThreadPool.h:279: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x00000000169bf193 5. /build/src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x00000000169bf518 6. /build/src/Server/TCPHandler.cpp:1237: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x00000000168f1525 7. /build/src/Server/TCPHandler.cpp:678: DB::TCPHandler::runImpl() @ 0x00000000168e68e5 8. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 9. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 10. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 11. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 12. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 13. ? @ 0x00007fbc6213eac3 14. ? @ 0x00007fbc621d0850 2025.07.28 12:02:25.817848 [ 62065 ] {550f85a9-0a95-4ce4-82d0-aa6e8dacd6f6} executeQuery: Code: 394. DB::Exception: Query was cancelled. (QUERY_WAS_CANCELLED) (version 25.3.6.10636.altinitytest (altinity build)) (from [::1]:34244) (comment: 02461_cancel_finish_race.sh) (query 1, line 1) (in query: KILL QUERY WHERE current_database = 'test_dtwle8fg' SYNC FORMAT Null), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000000a074fcb 4. /build/src/Interpreters/ProcessList.cpp:567: DB::QueryStatus::throwQueryWasCancelled() const @ 0x0000000014a4bc85 5. /build/src/Interpreters/ProcessList.cpp:520: DB::QueryStatus::throwProperExceptionIfNeeded(unsigned long const&, unsigned long const&) @ 0x0000000014a4bbd9 6. /build/src/Interpreters/ProcessList.cpp:557: DB::QueryStatus::checkTimeLimit() @ 0x0000000014a4c2cd 7. /build/src/Processors/Executors/PipelineExecutor.cpp:206: DB::PipelineExecutor::finalizeExecution() @ 0x00000000169b13ba 8. /build/src/Processors/Executors/PipelineExecutor.cpp:153: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x00000000169b0584 9. /build/src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:se190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169bfeab 10. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc3d92 11. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fcca080 12. ? @ 0x00007fbc6213eac3 13. ? @ 0x00007fbc621d0850 2025.07.28 12:02:25.834225 [ 62065 ] {} TCPHandler: Code: 394. DB::Exception: Query was cancelled. (QUERY_WAS_CANCELLED), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000000a074fcb 4. /build/src/Interpreters/ProcessList.cpp:567: DB::QueryStatus::throwQueryWasCancelled() const @ 0x0000000014a4bc85 5. /build/src/Interpreters/ProcessList.cpp:520: DB::QueryStatus::throwProperExceptionIfNeeded(unsigned long const&, unsigned long const&) @ 0x0000000014a4bbd9 6. /build/src/Interpreters/ProcessList.cpp:557: DB::QueryStatus::checkTimeLimit() @ 0x0000000014a4c2cd 7. /build/src/Processors/Executors/PipelineExecutor.cpp:206: DB::PipelineExecutor::finalizeExecution() @ 0x00000000169b13ba 8. /build/src/Processors/Executors/PipelineExecutor.cpp:153: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x00000000169b0584 9. /build/src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:se190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169bfeab 10. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc3d92 11. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fcca080 12. ? @ 0x00007fbc6213eac3 13. ? @ 0x00007fbc621d0850 Job's origin stack trace: 0. /build/src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000000fc33b84 1. /build/src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000000fcc2ea7 2. /build/src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fcc535c 3. /build/src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000000fcc584d 4. /build/src/Common/ThreadPool.h:279: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x00000000169bf193 5. /build/src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x00000000169bf518 6. /build/src/Server/TCPHandler.cpp:1237: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x00000000168f1525 7. /build/src/Server/TCPHandler.cpp:678: DB::TCPHandler::runImpl() @ 0x00000000168e68e5 8. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 9. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 10. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 11. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 12. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 13. ? @ 0x00007fbc6213eac3 14. ? @ 0x00007fbc621d0850 2025.07.28 12:02:25.874204 [ 62103 ] {} TCPHandler: Code: 394. DB::Exception: Query '1f538b47-805e-42c3-bd58-6b14a7aec570' is killed in pending state. (QUERY_WAS_CANCELLED), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x000000000a06b56b 4. /build/src/Interpreters/executeQuery.cpp:1522: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c8a4ef 5. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 6. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 7. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 8. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 9. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 10. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 11. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 12. ? @ 0x00007fbc6213eac3 13. ? @ 0x00007fbc621d0850 2025.07.28 12:02:25.886172 [ 17256 ] {} TCPHandler: Code: 394. DB::Exception: Query was cancelled. (QUERY_WAS_CANCELLED), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000000a074fcb 4. /build/src/Interpreters/ProcessList.cpp:567: DB::QueryStatus::throwQueryWasCancelled() const @ 0x0000000014a4bc85 5. /build/src/Interpreters/ProcessList.cpp:520: DB::QueryStatus::throwProperExceptionIfNeeded(unsigned long const&, unsigned long const&) @ 0x0000000014a4bbd9 6. /build/src/Interpreters/ProcessList.cpp:557: DB::QueryStatus::checkTimeLimit() @ 0x0000000014a4c2cd 7. /build/src/Processors/Executors/PipelineExecutor.cpp:206: DB::PipelineExecutor::finalizeExecution() @ 0x00000000169b13ba 8. /build/src/Processors/Executors/PipelineExecutor.cpp:181: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x00000000169b1726 9. /build/src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x00000000169c081c 10. /build/src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x00000000169c0978 11. /build/src/Interpreters/InterpreterKillQueryQuery.cpp:439: DB::InterpreterKillQueryQuery::getSelectResult(String const&, String const&) @ 0x0000000014cf0f04 12. /build/src/Interpreters/InterpreterKillQueryQuery.cpp:222: DB::InterpreterKillQueryQuery::execute() @ 0x0000000014cebde2 13. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88dc9 14. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 15. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 16. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 17. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 18. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 19. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 20. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 21. ? @ 0x00007fbc6213eac3 22. ? @ 0x00007fbc621d0850 2025.07.28 12:02:25.904863 [ 62053 ] {} TCPHandler: Code: 394. DB::Exception: Query was cancelled. (QUERY_WAS_CANCELLED), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000000a074fcb 4. /build/src/Interpreters/ProcessList.cpp:567: DB::QueryStatus::throwQueryWasCancelled() const @ 0x0000000014a4bc85 5. /build/src/Interpreters/ProcessList.cpp:520: DB::QueryStatus::throwProperExceptionIfNeeded(unsigned long const&, unsigned long const&) @ 0x0000000014a4bbd9 6. /build/src/Interpreters/ProcessList.cpp:557: DB::QueryStatus::checkTimeLimit() @ 0x0000000014a4c2cd 7. /build/src/Processors/Executors/PipelineExecutor.cpp:206: DB::PipelineExecutor::finalizeExecution() @ 0x00000000169b13ba 8. /build/src/Processors/Executors/PipelineExecutor.cpp:181: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x00000000169b1726 9. /build/src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x00000000169c081c 10. /build/src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x00000000169c0978 11. /build/src/Interpreters/InterpreterKillQueryQuery.cpp:442: DB::InterpreterKillQueryQuery::getSelectResult(String const&, String const&) @ 0x0000000014cf0f6b 12. /build/src/Interpreters/InterpreterKillQueryQuery.cpp:222: DB::InterpreterKillQueryQuery::execute() @ 0x0000000014cebde2 13. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88dc9 14. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 15. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 16. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 17. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 18. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 19. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 20. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 21. ? @ 0x00007fbc6213eac3 22. ? @ 0x00007fbc621d0850 2025.07.28 12:02:25.931794 [ 4963 ] {} TCPHandler: Code: 394. DB::Exception: Query was cancelled. (QUERY_WAS_CANCELLED), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000000a074fcb 4. /build/src/Interpreters/ProcessList.cpp:567: DB::QueryStatus::throwQueryWasCancelled() const @ 0x0000000014a4bc85 5. /build/src/Interpreters/ProcessList.cpp:520: DB::QueryStatus::throwProperExceptionIfNeeded(unsigned long const&, unsigned long const&) @ 0x0000000014a4bbd9 6. /build/src/Interpreters/ProcessList.cpp:531: DB::QueryStatus::addPipelineExecutor(DB::PipelineExecutor*) @ 0x0000000014a4bd9c 7. /build/src/Processors/Executors/PipelineExecutor.cpp:73: DB::PipelineExecutor::PipelineExecutor(std::shared_ptr, std::allocator>>>&, std::shared_ptr) @ 0x00000000169afe31 8. /build/contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x00000000169c07b5 9. /build/src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x00000000169c0978 10. /build/src/Interpreters/InterpreterKillQueryQuery.cpp:439: DB::InterpreterKillQueryQuery::getSelectResult(String const&, String const&) @ 0x0000000014cf0f04 11. /build/src/Interpreters/InterpreterKillQueryQuery.cpp:222: DB::InterpreterKillQueryQuery::execute() @ 0x0000000014cebde2 12. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88dc9 13. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 14. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 15. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 16. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 17. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 18. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 19. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 20. ? @ 0x00007fbc6213eac3 21. ? @ 0x00007fbc621d0850 2025.07.28 12:02:25.935279 [ 62314 ] {} TCPHandler: Code: 394. DB::Exception: Query was cancelled. (QUERY_WAS_CANCELLED), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000000a074fcb 4. /build/src/Interpreters/ProcessList.cpp:567: DB::QueryStatus::throwQueryWasCancelled() const @ 0x0000000014a4bc85 5. /build/src/Interpreters/ProcessList.cpp:520: DB::QueryStatus::throwProperExceptionIfNeeded(unsigned long const&, unsigned long const&) @ 0x0000000014a4bbd9 6. /build/src/Interpreters/ProcessList.cpp:557: DB::QueryStatus::checkTimeLimit() @ 0x0000000014a4c2cd 7. /build/src/Processors/Executors/PipelineExecutor.cpp:206: DB::PipelineExecutor::finalizeExecution() @ 0x00000000169b13ba 8. /build/src/Processors/Executors/PipelineExecutor.cpp:181: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x00000000169b1726 9. /build/src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x00000000169c081c 10. /build/src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x00000000169c0978 11. /build/src/Interpreters/InterpreterKillQueryQuery.cpp:439: DB::InterpreterKillQueryQuery::getSelectResult(String const&, String const&) @ 0x0000000014cf0f04 12. /build/src/Interpreters/InterpreterKillQueryQuery.cpp:222: DB::InterpreterKillQueryQuery::execute() @ 0x0000000014cebde2 13. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88dc9 14. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 15. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 16. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 17. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 18. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 19. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 20. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 21. ? @ 0x00007fbc6213eac3 22. ? @ 0x00007fbc621d0850 2025.07.28 12:02:26.077855 [ 62114 ] {9ff32d0d-e1a6-49e5-b8d1-d824e55f6174} executeQuery: Code: 394. DB::Exception: Query was cancelled. (QUERY_WAS_CANCELLED) (version 25.3.6.10636.altinitytest (altinity build)) (from [::1]:34468) (comment: 02461_cancel_finish_race.sh) (query 1, line 1) (in query: KILL QUERY WHERE current_database = 'test_dtwle8fg' SYNC FORMAT Null), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000000a074fcb 4. /build/src/Interpreters/ProcessList.cpp:567: DB::QueryStatus::throwQueryWasCancelled() const @ 0x0000000014a4bc85 5. /build/src/Interpreters/ProcessList.cpp:520: DB::QueryStatus::throwProperExceptionIfNeeded(unsigned long const&, unsigned long const&) @ 0x0000000014a4bbd9 6. /build/src/Interpreters/ProcessList.cpp:557: DB::QueryStatus::checkTimeLimit() @ 0x0000000014a4c2cd 7. /build/src/Processors/Executors/PipelineExecutor.cpp:206: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x00000000169b03a3 8. /build/src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:se190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169bfeab 9. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc3d92 10. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fcca080 11. ? @ 0x00007fbc6213eac3 12. ? @ 0x00007fbc621d0850 2025.07.28 12:02:26.119957 [ 62114 ] {} TCPHandler: Code: 394. DB::Exception: Query was cancelled. (QUERY_WAS_CANCELLED), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000000a074fcb 4. /build/src/Interpreters/ProcessList.cpp:567: DB::QueryStatus::throwQueryWasCancelled() const @ 0x0000000014a4bc85 5. /build/src/Interpreters/ProcessList.cpp:520: DB::QueryStatus::throwProperExceptionIfNeeded(unsigned long const&, unsigned long const&) @ 0x0000000014a4bbd9 6. /build/src/Interpreters/ProcessList.cpp:557: DB::QueryStatus::checkTimeLimit() @ 0x0000000014a4c2cd 7. /build/src/Processors/Executors/PipelineExecutor.cpp:206: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x00000000169b03a3 8. /build/src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:se190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169bfeab 9. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc3d92 10. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fcca080 11. ? @ 0x00007fbc6213eac3 12. ? @ 0x00007fbc621d0850 Job's origin stack trace: 0. /build/src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000000fc33b84 1. /build/src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000000fcc2ea7 2. /build/src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fcc535c 3. /build/src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000000fcc584d 4. /build/src/Common/ThreadPool.h:279: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x00000000169bf193 5. /build/src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x00000000169bf518 6. /build/src/Server/TCPHandler.cpp:1237: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x00000000168f1525 7. /build/src/Server/TCPHandler.cpp:678: DB::TCPHandler::runImpl() @ 0x00000000168e68e5 8. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 9. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 10. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 11. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 12. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 13. ? @ 0x00007fbc6213eac3 14. ? @ 0x00007fbc621d0850 2025.07.28 12:02:26.187843 [ 4900 ] {} TCPHandler: Code: 394. DB::Exception: Query was cancelled. (QUERY_WAS_CANCELLED), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000000a074fcb 4. /build/src/Interpreters/ProcessList.cpp:567: DB::QueryStatus::throwQueryWasCancelled() const @ 0x0000000014a4bc85 5. /build/src/Interpreters/ProcessList.cpp:520: DB::QueryStatus::throwProperExceptionIfNeeded(unsigned long const&, unsigned long const&) @ 0x0000000014a4bbd9 6. /build/src/Interpreters/ProcessList.cpp:557: DB::QueryStatus::checkTimeLimit() @ 0x0000000014a4c2cd 7. /build/src/Processors/Executors/PipelineExecutor.cpp:206: DB::PipelineExecutor::finalizeExecution() @ 0x00000000169b13ba 8. /build/src/Processors/Executors/PipelineExecutor.cpp:181: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x00000000169b1726 9. /build/src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x00000000169c081c 10. /build/src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x00000000169c0978 11. /build/src/Interpreters/InterpreterKillQueryQuery.cpp:439: DB::InterpreterKillQueryQuery::getSelectResult(String const&, String const&) @ 0x0000000014cf0f04 12. /build/src/Interpreters/InterpreterKillQueryQuery.cpp:222: DB::InterpreterKillQueryQuery::execute() @ 0x0000000014cebde2 13. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88dc9 14. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 15. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 16. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 17. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 18. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 19. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 20. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 21. ? @ 0x00007fbc6213eac3 22. ? @ 0x00007fbc621d0850 2025.07.28 12:02:26.302655 [ 7625 ] {} TCPHandler: Code: 394. DB::Exception: Query was cancelled. (QUERY_WAS_CANCELLED), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000000a074fcb 4. /build/src/Interpreters/ProcessList.cpp:567: DB::QueryStatus::throwQueryWasCancelled() const @ 0x0000000014a4bc85 5. /build/src/Interpreters/ProcessList.cpp:520: DB::QueryStatus::throwProperExceptionIfNeeded(unsigned long const&, unsigned long const&) @ 0x0000000014a4bbd9 6. /build/src/Interpreters/ProcessList.cpp:557: DB::QueryStatus::checkTimeLimit() @ 0x0000000014a4c2cd 7. /build/src/Processors/Executors/PipelineExecutor.cpp:206: DB::PipelineExecutor::finalizeExecution() @ 0x00000000169b13ba 8. /build/src/Processors/Executors/PipelineExecutor.cpp:181: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x00000000169b1726 9. /build/src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x00000000169c081c 10. /build/src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x00000000169c0978 11. /build/src/Interpreters/InterpreterKillQueryQuery.cpp:439: DB::InterpreterKillQueryQuery::getSelectResult(String const&, String const&) @ 0x0000000014cf0f04 12. /build/src/Interpreters/InterpreterKillQueryQuery.cpp:222: DB::InterpreterKillQueryQuery::execute() @ 0x0000000014cebde2 13. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88dc9 14. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 15. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 16. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 17. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 18. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 19. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 20. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 21. ? @ 0x00007fbc6213eac3 22. ? @ 0x00007fbc621d0850 2025.07.28 12:02:26.327746 [ 17255 ] {09e29b46-807d-46ca-bd26-f49356095e24} executeQuery: Code: 394. DB::Exception: Query was cancelled. (QUERY_WAS_CANCELLED) (version 25.3.6.10636.altinitytest (altinity build)) (from [::1]:34604) (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. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000000a074fcb 4. /build/src/Interpreters/ProcessList.cpp:567: DB::QueryStatus::throwQueryWasCancelled() const @ 0x0000000014a4bc85 5. /build/src/Interpreters/ProcessList.cpp:520: DB::QueryStatus::throwProperExceptionIfNeeded(unsigned long const&, unsigned long const&) @ 0x0000000014a4bbd9 6. /build/src/Interpreters/ProcessList.cpp:557: DB::QueryStatus::checkTimeLimit() @ 0x0000000014a4c2cd 7. /build/src/Processors/Executors/PipelineExecutor.cpp:206: DB::PipelineExecutor::finalizeExecution() @ 0x00000000169b13ba 8. /build/src/Processors/Executors/PipelineExecutor.cpp:153: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x00000000169b0584 9. /build/src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:se190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169bfeab 10. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc3d92 11. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fcca080 12. ? @ 0x00007fbc6213eac3 13. ? @ 0x00007fbc621d0850 2025.07.28 12:02:26.344462 [ 17255 ] {} TCPHandler: Code: 394. DB::Exception: Query was cancelled. (QUERY_WAS_CANCELLED), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000000a074fcb 4. /build/src/Interpreters/ProcessList.cpp:567: DB::QueryStatus::throwQueryWasCancelled() const @ 0x0000000014a4bc85 5. /build/src/Interpreters/ProcessList.cpp:520: DB::QueryStatus::throwProperExceptionIfNeeded(unsigned long const&, unsigned long const&) @ 0x0000000014a4bbd9 6. /build/src/Interpreters/ProcessList.cpp:557: DB::QueryStatus::checkTimeLimit() @ 0x0000000014a4c2cd 7. /build/src/Processors/Executors/PipelineExecutor.cpp:206: DB::PipelineExecutor::finalizeExecution() @ 0x00000000169b13ba 8. /build/src/Processors/Executors/PipelineExecutor.cpp:153: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x00000000169b0584 9. /build/src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:se190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169bfeab 10. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc3d92 11. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fcca080 12. ? @ 0x00007fbc6213eac3 13. ? @ 0x00007fbc621d0850 Job's origin stack trace: 0. /build/src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000000fc33b84 1. /build/src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000000fcc2ea7 2. /build/src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fcc535c 3. /build/src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000000fcc584d 4. /build/src/Common/ThreadPool.h:279: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x00000000169bf193 5. /build/src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x00000000169bf518 6. /build/src/Server/TCPHandler.cpp:1237: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x00000000168f1525 7. /build/src/Server/TCPHandler.cpp:678: DB::TCPHandler::runImpl() @ 0x00000000168e68e5 8. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 9. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 10. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 11. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 12. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 13. ? @ 0x00007fbc6213eac3 14. ? @ 0x00007fbc621d0850 2025.07.28 12:02:26.356606 [ 62057 ] {} TCPHandler: Code: 394. DB::Exception: Query was cancelled. (QUERY_WAS_CANCELLED), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000000a074fcb 4. /build/src/Interpreters/ProcessList.cpp:567: DB::QueryStatus::throwQueryWasCancelled() const @ 0x0000000014a4bc85 5. /build/src/Interpreters/ProcessList.cpp:520: DB::QueryStatus::throwProperExceptionIfNeeded(unsigned long const&, unsigned long const&) @ 0x0000000014a4bbd9 6. /build/src/Interpreters/ProcessList.cpp:531: DB::QueryStatus::addPipelineExecutor(DB::PipelineExecutor*) @ 0x0000000014a4bd9c 7. /build/src/Processors/Executors/PipelineExecutor.cpp:73: DB::PipelineExecutor::PipelineExecutor(std::shared_ptr, std::allocator>>>&, std::shared_ptr) @ 0x00000000169afe31 8. /build/contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x00000000169c07b5 9. /build/src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x00000000169c0978 10. /build/src/Interpreters/InterpreterKillQueryQuery.cpp:439: DB::InterpreterKillQueryQuery::getSelectResult(String const&, String const&) @ 0x0000000014cf0f04 11. /build/src/Interpreters/InterpreterKillQueryQuery.cpp:222: DB::InterpreterKillQueryQuery::execute() @ 0x0000000014cebde2 12. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88dc9 13. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 14. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 15. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 16. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 17. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 18. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 19. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 20. ? @ 0x00007fbc6213eac3 21. ? @ 0x00007fbc621d0850 2025.07.28 12:02:26.388243 [ 62103 ] {b6ed85a9-f639-4e20-a4d5-b2552f149674} executeQuery: Code: 394. DB::Exception: Query was cancelled. (QUERY_WAS_CANCELLED) (version 25.3.6.10636.altinitytest (altinity build)) (from [::1]:34576) (comment: 02461_cancel_finish_race.sh) (query 1, line 1) (in query: KILL QUERY WHERE current_database = 'test_dtwle8fg' SYNC FORMAT Null), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000000a074fcb 4. /build/src/Interpreters/ProcessList.cpp:567: DB::QueryStatus::throwQueryWasCancelled() const @ 0x0000000014a4bc85 5. /build/src/Interpreters/ProcessList.cpp:520: DB::QueryStatus::throwProperExceptionIfNeeded(unsigned long const&, unsigned long const&) @ 0x0000000014a4bbd9 6. /build/src/Interpreters/ProcessList.cpp:557: DB::QueryStatus::checkTimeLimit() @ 0x0000000014a4c2cd 7. /build/src/Processors/Executors/PipelineExecutor.cpp:206: DB::PipelineExecutor::finalizeExecution() @ 0x00000000169b13ba 8. /build/src/Processors/Executors/PipelineExecutor.cpp:153: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x00000000169b0584 9. /build/src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:se190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169bfeab 10. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc3d92 11. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fcca080 12. ? @ 0x00007fbc6213eac3 13. ? @ 0x00007fbc621d0850 2025.07.28 12:02:26.391556 [ 62103 ] {} TCPHandler: Code: 394. DB::Exception: Query was cancelled. (QUERY_WAS_CANCELLED), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000000a074fcb 4. /build/src/Interpreters/ProcessList.cpp:567: DB::QueryStatus::throwQueryWasCancelled() const @ 0x0000000014a4bc85 5. /build/src/Interpreters/ProcessList.cpp:520: DB::QueryStatus::throwProperExceptionIfNeeded(unsigned long const&, unsigned long const&) @ 0x0000000014a4bbd9 6. /build/src/Interpreters/ProcessList.cpp:557: DB::QueryStatus::checkTimeLimit() @ 0x0000000014a4c2cd 7. /build/src/Processors/Executors/PipelineExecutor.cpp:206: DB::PipelineExecutor::finalizeExecution() @ 0x00000000169b13ba 8. /build/src/Processors/Executors/PipelineExecutor.cpp:153: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x00000000169b0584 9. /build/src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:se190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169bfeab 10. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc3d92 11. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fcca080 12. ? @ 0x00007fbc6213eac3 13. ? @ 0x00007fbc621d0850 Job's origin stack trace: 0. /build/src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000000fc33b84 1. /build/src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000000fcc2ea7 2. /build/src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fcc535c 3. /build/src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000000fcc584d 4. /build/src/Common/ThreadPool.h:279: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x00000000169bf193 5. /build/src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x00000000169bf518 6. /build/src/Server/TCPHandler.cpp:1237: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x00000000168f1525 7. /build/src/Server/TCPHandler.cpp:678: DB::TCPHandler::runImpl() @ 0x00000000168e68e5 8. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 9. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 10. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 11. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 12. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 13. ? @ 0x00007fbc6213eac3 14. ? @ 0x00007fbc621d0850 2025.07.28 12:02:26.412433 [ 63425 ] {4f56fcee-3b4c-490b-9d09-0a777312a8b3} executeQuery: Code: 394. DB::Exception: Query was cancelled. (QUERY_WAS_CANCELLED) (version 25.3.6.10636.altinitytest (altinity build)) (from [::1]:34650) (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. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000000a074fcb 4. /build/src/Interpreters/ProcessList.cpp:567: DB::QueryStatus::throwQueryWasCancelled() const @ 0x0000000014a4bc85 5. /build/src/Interpreters/ProcessList.cpp:520: DB::QueryStatus::throwProperExceptionIfNeeded(unsigned long const&, unsigned long const&) @ 0x0000000014a4bbd9 6. /build/src/Interpreters/ProcessList.cpp:557: DB::QueryStatus::checkTimeLimit() @ 0x0000000014a4c2cd 7. /build/src/Processors/Executors/PipelineExecutor.cpp:206: DB::PipelineExecutor::finalizeExecution() @ 0x00000000169b13ba 8. /build/src/Processors/Executors/PipelineExecutor.cpp:153: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x00000000169b0584 9. /build/src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:se190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169bfeab 10. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc3d92 11. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fcca080 12. ? @ 0x00007fbc6213eac3 13. ? @ 0x00007fbc621d0850 2025.07.28 12:02:26.421397 [ 4963 ] {} TCPHandler: Code: 394. DB::Exception: Query '3ea5d152-1a9b-468d-b8aa-0f30caa2a1b4' is killed in pending state. (QUERY_WAS_CANCELLED), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x000000000a06b56b 4. /build/src/Interpreters/executeQuery.cpp:1522: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c8a4ef 5. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 6. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 7. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 8. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 9. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 10. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 11. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 12. ? @ 0x00007fbc6213eac3 13. ? @ 0x00007fbc621d0850 2025.07.28 12:02:26.421555 [ 63425 ] {} TCPHandler: Code: 394. DB::Exception: Query was cancelled. (QUERY_WAS_CANCELLED), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000000a074fcb 4. /build/src/Interpreters/ProcessList.cpp:567: DB::QueryStatus::throwQueryWasCancelled() const @ 0x0000000014a4bc85 5. /build/src/Interpreters/ProcessList.cpp:520: DB::QueryStatus::throwProperExceptionIfNeeded(unsigned long const&, unsigned long const&) @ 0x0000000014a4bbd9 6. /build/src/Interpreters/ProcessList.cpp:557: DB::QueryStatus::checkTimeLimit() @ 0x0000000014a4c2cd 7. /build/src/Processors/Executors/PipelineExecutor.cpp:206: DB::PipelineExecutor::finalizeExecution() @ 0x00000000169b13ba 8. /build/src/Processors/Executors/PipelineExecutor.cpp:153: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x00000000169b0584 9. /build/src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:se190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169bfeab 10. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc3d92 11. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fcca080 12. ? @ 0x00007fbc6213eac3 13. ? @ 0x00007fbc621d0850 Job's origin stack trace: 0. /build/src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000000fc33b84 1. /build/src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000000fcc2ea7 2. /build/src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fcc535c 3. /build/src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000000fcc584d 4. /build/src/Common/ThreadPool.h:279: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x00000000169bf193 5. /build/src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x00000000169bf518 6. /build/src/Server/TCPHandler.cpp:1237: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x00000000168f1525 7. /build/src/Server/TCPHandler.cpp:678: DB::TCPHandler::runImpl() @ 0x00000000168e68e5 8. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 9. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 10. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 11. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 12. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 13. ? @ 0x00007fbc6213eac3 14. ? @ 0x00007fbc621d0850 2025.07.28 12:02:26.637025 [ 62065 ] {} TCPHandler: Code: 394. DB::Exception: Query was cancelled. (QUERY_WAS_CANCELLED), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000000a074fcb 4. /build/src/Interpreters/ProcessList.cpp:567: DB::QueryStatus::throwQueryWasCancelled() const @ 0x0000000014a4bc85 5. /build/src/Interpreters/ProcessList.cpp:520: DB::QueryStatus::throwProperExceptionIfNeeded(unsigned long const&, unsigned long const&) @ 0x0000000014a4bbd9 6. /build/src/Interpreters/ProcessList.cpp:531: DB::QueryStatus::addPipelineExecutor(DB::PipelineExecutor*) @ 0x0000000014a4bd9c 7. /build/src/Processors/Executors/PipelineExecutor.cpp:73: DB::PipelineExecutor::PipelineExecutor(std::shared_ptr, std::allocator>>>&, std::shared_ptr) @ 0x00000000169afe31 8. /build/contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x00000000169c07b5 9. /build/src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x00000000169c0978 10. /build/src/Interpreters/InterpreterKillQueryQuery.cpp:439: DB::InterpreterKillQueryQuery::getSelectResult(String const&, String const&) @ 0x0000000014cf0f04 11. /build/src/Interpreters/InterpreterKillQueryQuery.cpp:222: DB::InterpreterKillQueryQuery::execute() @ 0x0000000014cebde2 12. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88dc9 13. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 14. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 15. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 16. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 17. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 18. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 19. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 20. ? @ 0x00007fbc6213eac3 21. ? @ 0x00007fbc621d0850 2025.07.28 12:02:26.640848 [ 3971 ] {} test_13.rmt2 (7f9b740d-015c-470e-8cc6-8ba33be0dc63): auto DB::StorageReplicatedMergeTree::processQueueEntry(ReplicatedMergeTreeQueue::SelectedEntryPtr)::(anonymous class)::operator()(LogEntryPtr &) const: Code: 86. DB::HTTPException: Received error from remote server http://146b4357c08d:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Ftest%2F01165%2Ftest_13%2Frmt%2Freplicas%2F1&part=20250728_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.6.10636.altinitytest (altinity build)) '. (RECEIVED_ERROR_FROM_REMOTE_IO_SERVER), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.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 const&, int&&, String const&, unsigned long&&, String const&) @ 0x000000000feda8d9 4. /build/src/IO/HTTPCommon.cpp:104: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x000000000feda6e2 5. /build/src/IO/HTTPCommon.cpp:93: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x000000000feda537 6. /build/src/IO/ReadWriteBufferFromHTTP.cpp:277: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x000000001184a4c4 7. /build/src/IO/ReadWriteBufferFromHTTP.cpp:285: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x000000001184a615 8. /build/src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x000000001184ae59 9. /build/src/IO/ReadWriteBufferFromHTTP.cpp:472: void std::__function::__policy_invoker::__call_impl[abi:se190107]>(std::__function::__policy_storage const*) @ 0x000000001184cedd 10. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001184858b 11. /build/src/IO/ReadWriteBufferFromHTTP.cpp:465: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x000000001184bf0b 12. /build/src/IO/ReadBuffer.h:60: DB::ReadBuffer::next() @ 0x000000000a148c7b 13. /build/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) @ 0x0000000011849fb2 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]>&)>&, 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&) @ 0x0000000011841980 15. /build/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) @ 0x000000001621208e 16. /build/src/Storages/StorageReplicatedMergeTree.cpp:5228: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl[abi:se190107] const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000015f9a5fe 17. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000015ed8bfd 18. /build/src/Storages/StorageReplicatedMergeTree.cpp:2514: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x0000000015ec9aab 19. /build/src/Storages/StorageReplicatedMergeTree.cpp:2349: DB::StorageReplicatedMergeTree::executeLogEntry(DB::ReplicatedMergeTreeLogEntry&) @ 0x0000000015eba91b 20. /build/src/Storages/StorageReplicatedMergeTree.cpp:3876: bool std::__function::__policy_invoker&)>::__call_impl[abi:se190107])::$_1, bool (std::shared_ptr&)>>(std::__function::__policy_storage const*, std::shared_ptr&) @ 0x0000000015f9837e 21. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000165d6fc3 22. /build/src/Storages/StorageReplicatedMergeTree.cpp:3872: DB::StorageReplicatedMergeTree::processQueueEntry(std::shared_ptr) @ 0x0000000015efc18a 23. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001624c1b2 24. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000162f9c70 25. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x00000000162fa55a 26. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc6653 27. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000000fccc4c3 28. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc3d92 29. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fcca080 30. ? @ 0x00007fbc6213eac3 31. ? @ 0x00007fbc621d0850 (version 25.3.6.10636.altinitytest (altinity build)) 2025.07.28 12:02:26.655559 [ 5112 ] {} TCPHandler: Code: 394. DB::Exception: Query was cancelled. (QUERY_WAS_CANCELLED), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000000a074fcb 4. /build/src/Interpreters/ProcessList.cpp:567: DB::QueryStatus::throwQueryWasCancelled() const @ 0x0000000014a4bc85 5. /build/src/Interpreters/ProcessList.cpp:520: DB::QueryStatus::throwProperExceptionIfNeeded(unsigned long const&, unsigned long const&) @ 0x0000000014a4bbd9 6. /build/src/Interpreters/ProcessList.cpp:531: DB::QueryStatus::addPipelineExecutor(DB::PipelineExecutor*) @ 0x0000000014a4bd9c 7. /build/src/Processors/Executors/PipelineExecutor.cpp:73: DB::PipelineExecutor::PipelineExecutor(std::shared_ptr, std::allocator>>>&, std::shared_ptr) @ 0x00000000169afe31 8. /build/contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x00000000169c07b5 9. /build/src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x00000000169c0978 10. /build/src/Interpreters/InterpreterKillQueryQuery.cpp:439: DB::InterpreterKillQueryQuery::getSelectResult(String const&, String const&) @ 0x0000000014cf0f04 11. /build/src/Interpreters/InterpreterKillQueryQuery.cpp:222: DB::InterpreterKillQueryQuery::execute() @ 0x0000000014cebde2 12. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88dc9 13. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 14. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 15. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 16. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 17. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 18. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 19. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 20. ? @ 0x00007fbc6213eac3 21. ? @ 0x00007fbc621d0850 2025.07.28 12:02:26.659066 [ 62093 ] {2f965545-2b3a-4d83-ab56-9647489aec0f} executeQuery: Code: 394. DB::Exception: Query was cancelled. (QUERY_WAS_CANCELLED) (version 25.3.6.10636.altinitytest (altinity build)) (from [::1]:34742) (comment: 02461_cancel_finish_race.sh) (query 1, line 1) (in query: KILL QUERY WHERE current_database = 'test_dtwle8fg' SYNC FORMAT Null), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000000a074fcb 4. /build/src/Interpreters/ProcessList.cpp:567: DB::QueryStatus::throwQueryWasCancelled() const @ 0x0000000014a4bc85 5. /build/src/Interpreters/ProcessList.cpp:520: DB::QueryStatus::throwProperExceptionIfNeeded(unsigned long const&, unsigned long const&) @ 0x0000000014a4bbd9 6. /build/src/Interpreters/ProcessList.cpp:531: DB::QueryStatus::addPipelineExecutor(DB::PipelineExecutor*) @ 0x0000000014a4bd9c 7. /build/src/Processors/Executors/PipelineExecutor.cpp:73: DB::PipelineExecutor::PipelineExecutor(std::shared_ptr, std::allocator>>>&, std::shared_ptr) @ 0x00000000169afe31 8. /build/contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x00000000169bef66 9. /build/src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x00000000169bf518 10. /build/src/Server/TCPHandler.cpp:1237: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x00000000168f1525 11. /build/src/Server/TCPHandler.cpp:678: DB::TCPHandler::runImpl() @ 0x00000000168e68e5 12. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 13. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 14. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 16. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 17. ? @ 0x00007fbc6213eac3 18. ? @ 0x00007fbc621d0850 2025.07.28 12:02:26.727434 [ 62093 ] {} TCPHandler: Code: 394. DB::Exception: Query was cancelled. (QUERY_WAS_CANCELLED), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000000a074fcb 4. /build/src/Interpreters/ProcessList.cpp:567: DB::QueryStatus::throwQueryWasCancelled() const @ 0x0000000014a4bc85 5. /build/src/Interpreters/ProcessList.cpp:520: DB::QueryStatus::throwProperExceptionIfNeeded(unsigned long const&, unsigned long const&) @ 0x0000000014a4bbd9 6. /build/src/Interpreters/ProcessList.cpp:531: DB::QueryStatus::addPipelineExecutor(DB::PipelineExecutor*) @ 0x0000000014a4bd9c 7. /build/src/Processors/Executors/PipelineExecutor.cpp:73: DB::PipelineExecutor::PipelineExecutor(std::shared_ptr, std::allocator>>>&, std::shared_ptr) @ 0x00000000169afe31 8. /build/contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x00000000169bef66 9. /build/src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x00000000169bf518 10. /build/src/Server/TCPHandler.cpp:1237: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x00000000168f1525 11. /build/src/Server/TCPHandler.cpp:678: DB::TCPHandler::runImpl() @ 0x00000000168e68e5 12. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 13. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 14. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 16. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 17. ? @ 0x00007fbc6213eac3 18. ? @ 0x00007fbc621d0850 2025.07.28 12:02:26.738325 [ 62314 ] {c584a330-7649-45a7-91c3-8c89e9d5ebf6} executeQuery: Code: 394. DB::Exception: Query was cancelled. (QUERY_WAS_CANCELLED) (version 25.3.6.10636.altinitytest (altinity build)) (from [::1]:34612) (comment: 02461_cancel_finish_race.sh) (query 1, line 1) (in query: KILL QUERY WHERE current_database = 'test_dtwle8fg' SYNC FORMAT Null), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000000a074fcb 4. /build/src/Interpreters/ProcessList.cpp:567: DB::QueryStatus::throwQueryWasCancelled() const @ 0x0000000014a4bc85 5. /build/src/Interpreters/ProcessList.cpp:520: DB::QueryStatus::throwProperExceptionIfNeeded(unsigned long const&, unsigned long const&) @ 0x0000000014a4bbd9 6. /build/src/Interpreters/ProcessList.cpp:557: DB::QueryStatus::checkTimeLimit() @ 0x0000000014a4c2cd 7. /build/src/Processors/Executors/PipelineExecutor.cpp:206: DB::PipelineExecutor::finalizeExecution() @ 0x00000000169b13ba 8. /build/src/Processors/Executors/PipelineExecutor.cpp:153: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x00000000169b0584 9. /build/src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:se190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169bfeab 10. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc3d92 11. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fcca080 12. ? @ 0x00007fbc6213eac3 13. ? @ 0x00007fbc621d0850 2025.07.28 12:02:26.756830 [ 62314 ] {} TCPHandler: Code: 394. DB::Exception: Query was cancelled. (QUERY_WAS_CANCELLED), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000000a074fcb 4. /build/src/Interpreters/ProcessList.cpp:567: DB::QueryStatus::throwQueryWasCancelled() const @ 0x0000000014a4bc85 5. /build/src/Interpreters/ProcessList.cpp:520: DB::QueryStatus::throwProperExceptionIfNeeded(unsigned long const&, unsigned long const&) @ 0x0000000014a4bbd9 6. /build/src/Interpreters/ProcessList.cpp:557: DB::QueryStatus::checkTimeLimit() @ 0x0000000014a4c2cd 7. /build/src/Processors/Executors/PipelineExecutor.cpp:206: DB::PipelineExecutor::finalizeExecution() @ 0x00000000169b13ba 8. /build/src/Processors/Executors/PipelineExecutor.cpp:153: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x00000000169b0584 9. /build/src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:se190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169bfeab 10. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc3d92 11. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fcca080 12. ? @ 0x00007fbc6213eac3 13. ? @ 0x00007fbc621d0850 Job's origin stack trace: 0. /build/src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000000fc33b84 1. /build/src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000000fcc2ea7 2. /build/src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fcc535c 3. /build/src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000000fcc584d 4. /build/src/Common/ThreadPool.h:279: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x00000000169bf193 5. /build/src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x00000000169bf518 6. /build/src/Server/TCPHandler.cpp:1237: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x00000000168f1525 7. /build/src/Server/TCPHandler.cpp:678: DB::TCPHandler::runImpl() @ 0x00000000168e68e5 8. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 9. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 10. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 11. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 12. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 13. ? @ 0x00007fbc6213eac3 14. ? @ 0x00007fbc621d0850 2025.07.28 12:02:26.828809 [ 3967 ] {} test_13.rmt2 (7f9b740d-015c-470e-8cc6-8ba33be0dc63): auto DB::StorageReplicatedMergeTree::processQueueEntry(ReplicatedMergeTreeQueue::SelectedEntryPtr)::(anonymous class)::operator()(LogEntryPtr &) const: Code: 86. DB::HTTPException: Received error from remote server http://146b4357c08d:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Ftest%2F01165%2Ftest_13%2Frmt%2Freplicas%2F1&part=20250728_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.6.10636.altinitytest (altinity build)) '. (RECEIVED_ERROR_FROM_REMOTE_IO_SERVER), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.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 const&, int&&, String const&, unsigned long&&, String const&) @ 0x000000000feda8d9 4. /build/src/IO/HTTPCommon.cpp:104: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x000000000feda6e2 5. /build/src/IO/HTTPCommon.cpp:93: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x000000000feda537 6. /build/src/IO/ReadWriteBufferFromHTTP.cpp:277: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x000000001184a4c4 7. /build/src/IO/ReadWriteBufferFromHTTP.cpp:285: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x000000001184a615 8. /build/src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x000000001184ae59 9. /build/src/IO/ReadWriteBufferFromHTTP.cpp:472: void std::__function::__policy_invoker::__call_impl[abi:se190107]>(std::__function::__policy_storage const*) @ 0x000000001184cedd 10. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001184858b 11. /build/src/IO/ReadWriteBufferFromHTTP.cpp:465: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x000000001184bf0b 12. /build/src/IO/ReadBuffer.h:60: DB::ReadBuffer::next() @ 0x000000000a148c7b 13. /build/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) @ 0x0000000011849fb2 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]>&)>&, 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&) @ 0x0000000011841980 15. /build/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) @ 0x000000001621208e 16. /build/src/Storages/StorageReplicatedMergeTree.cpp:5228: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl[abi:se190107] const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000015f9a5fe 17. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000015ed8bfd 18. /build/src/Storages/StorageReplicatedMergeTree.cpp:2514: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x0000000015ec9aab 19. /build/src/Storages/StorageReplicatedMergeTree.cpp:2349: DB::StorageReplicatedMergeTree::executeLogEntry(DB::ReplicatedMergeTreeLogEntry&) @ 0x0000000015eba91b 20. /build/src/Storages/StorageReplicatedMergeTree.cpp:3876: bool std::__function::__policy_invoker&)>::__call_impl[abi:se190107])::$_1, bool (std::shared_ptr&)>>(std::__function::__policy_storage const*, std::shared_ptr&) @ 0x0000000015f9837e 21. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000165d6fc3 22. /build/src/Storages/StorageReplicatedMergeTree.cpp:3872: DB::StorageReplicatedMergeTree::processQueueEntry(std::shared_ptr) @ 0x0000000015efc18a 23. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001624c1b2 24. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000162f9c70 25. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x00000000162fa55a 26. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc6653 27. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000000fccc4c3 28. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc3d92 29. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fcca080 30. ? @ 0x00007fbc6213eac3 31. ? @ 0x00007fbc621d0850 (version 25.3.6.10636.altinitytest (altinity build)) 2025.07.28 12:02:26.831859 [ 17256 ] {} TCPHandler: Code: 394. DB::Exception: Query was cancelled. (QUERY_WAS_CANCELLED), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000000a074fcb 4. /build/src/Interpreters/ProcessList.cpp:567: DB::QueryStatus::throwQueryWasCancelled() const @ 0x0000000014a4bc85 5. /build/src/Interpreters/ProcessList.cpp:520: DB::QueryStatus::throwProperExceptionIfNeeded(unsigned long const&, unsigned long const&) @ 0x0000000014a4bbd9 6. /build/src/Interpreters/ProcessList.cpp:531: DB::QueryStatus::addPipelineExecutor(DB::PipelineExecutor*) @ 0x0000000014a4bd9c 7. /build/src/Processors/Executors/PipelineExecutor.cpp:73: DB::PipelineExecutor::PipelineExecutor(std::shared_ptr, std::allocator>>>&, std::shared_ptr) @ 0x00000000169afe31 8. /build/contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x00000000169c07b5 9. /build/src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x00000000169c0978 10. /build/src/Interpreters/InterpreterKillQueryQuery.cpp:439: DB::InterpreterKillQueryQuery::getSelectResult(String const&, String const&) @ 0x0000000014cf0f04 11. /build/src/Interpreters/InterpreterKillQueryQuery.cpp:222: DB::InterpreterKillQueryQuery::execute() @ 0x0000000014cebde2 12. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88dc9 13. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 14. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 15. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 16. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 17. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 18. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 19. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 20. ? @ 0x00007fbc6213eac3 21. ? @ 0x00007fbc621d0850 2025.07.28 12:02:26.909561 [ 62114 ] {9ebe52c2-99c3-48b0-87ed-5413f6f4fb9a} executeQuery: Code: 394. DB::Exception: Query was cancelled. (QUERY_WAS_CANCELLED) (version 25.3.6.10636.altinitytest (altinity build)) (from [::1]:34730) (comment: 02461_cancel_finish_race.sh) (query 1, line 1) (in query: KILL QUERY WHERE current_database = 'test_dtwle8fg' SYNC FORMAT Null), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000000a074fcb 4. /build/src/Interpreters/ProcessList.cpp:567: DB::QueryStatus::throwQueryWasCancelled() const @ 0x0000000014a4bc85 5. /build/src/Interpreters/ProcessList.cpp:520: DB::QueryStatus::throwProperExceptionIfNeeded(unsigned long const&, unsigned long const&) @ 0x0000000014a4bbd9 6. /build/src/Interpreters/ProcessList.cpp:557: DB::QueryStatus::checkTimeLimit() @ 0x0000000014a4c2cd 7. /build/src/Processors/Executors/PipelineExecutor.cpp:206: DB::PipelineExecutor::finalizeExecution() @ 0x00000000169b13ba 8. /build/src/Processors/Executors/PipelineExecutor.cpp:153: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x00000000169b0584 9. /build/src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:se190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169bfeab 10. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc3d92 11. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fcca080 12. ? @ 0x00007fbc6213eac3 13. ? @ 0x00007fbc621d0850 2025.07.28 12:02:26.921805 [ 62114 ] {} TCPHandler: Code: 394. DB::Exception: Query was cancelled. (QUERY_WAS_CANCELLED), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000000a074fcb 4. /build/src/Interpreters/ProcessList.cpp:567: DB::QueryStatus::throwQueryWasCancelled() const @ 0x0000000014a4bc85 5. /build/src/Interpreters/ProcessList.cpp:520: DB::QueryStatus::throwProperExceptionIfNeeded(unsigned long const&, unsigned long const&) @ 0x0000000014a4bbd9 6. /build/src/Interpreters/ProcessList.cpp:557: DB::QueryStatus::checkTimeLimit() @ 0x0000000014a4c2cd 7. /build/src/Processors/Executors/PipelineExecutor.cpp:206: DB::PipelineExecutor::finalizeExecution() @ 0x00000000169b13ba 8. /build/src/Processors/Executors/PipelineExecutor.cpp:153: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x00000000169b0584 9. /build/src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:se190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169bfeab 10. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc3d92 11. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fcca080 12. ? @ 0x00007fbc6213eac3 13. ? @ 0x00007fbc621d0850 Job's origin stack trace: 0. /build/src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000000fc33b84 1. /build/src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000000fcc2ea7 2. /build/src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fcc535c 3. /build/src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000000fcc584d 4. /build/src/Common/ThreadPool.h:279: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x00000000169bf193 5. /build/src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x00000000169bf518 6. /build/src/Server/TCPHandler.cpp:1237: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x00000000168f1525 7. /build/src/Server/TCPHandler.cpp:678: DB::TCPHandler::runImpl() @ 0x00000000168e68e5 8. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 9. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 10. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 11. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 12. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 13. ? @ 0x00007fbc6213eac3 14. ? @ 0x00007fbc621d0850 2025.07.28 12:02:26.992945 [ 17252 ] {8ec64264-89ac-4ba3-9aa2-6420cf61f6dd} executeQuery: Code: 394. DB::Exception: Query was cancelled. (QUERY_WAS_CANCELLED) (version 25.3.6.10636.altinitytest (altinity build)) (from [::1]:34764) (comment: 02461_cancel_finish_race.sh) (query 1, line 1) (in query: KILL QUERY WHERE current_database = 'test_dtwle8fg' SYNC FORMAT Null), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000000a074fcb 4. /build/src/Interpreters/ProcessList.cpp:567: DB::QueryStatus::throwQueryWasCancelled() const @ 0x0000000014a4bc85 5. /build/src/Interpreters/ProcessList.cpp:520: DB::QueryStatus::throwProperExceptionIfNeeded(unsigned long const&, unsigned long const&) @ 0x0000000014a4bbd9 6. /build/src/Interpreters/ProcessList.cpp:557: DB::QueryStatus::checkTimeLimit() @ 0x0000000014a4c2cd 7. /build/src/Processors/Executors/PipelineExecutor.cpp:206: DB::PipelineExecutor::finalizeExecution() @ 0x00000000169b13ba 8. /build/src/Processors/Executors/PipelineExecutor.cpp:153: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x00000000169b0584 9. /build/src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:se190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169bfeab 10. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc3d92 11. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fcca080 12. ? @ 0x00007fbc6213eac3 13. ? @ 0x00007fbc621d0850 2025.07.28 12:02:27.006130 [ 17252 ] {} TCPHandler: Code: 394. DB::Exception: Query was cancelled. (QUERY_WAS_CANCELLED), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000000a074fcb 4. /build/src/Interpreters/ProcessList.cpp:567: DB::QueryStatus::throwQueryWasCancelled() const @ 0x0000000014a4bc85 5. /build/src/Interpreters/ProcessList.cpp:520: DB::QueryStatus::throwProperExceptionIfNeeded(unsigned long const&, unsigned long const&) @ 0x0000000014a4bbd9 6. /build/src/Interpreters/ProcessList.cpp:557: DB::QueryStatus::checkTimeLimit() @ 0x0000000014a4c2cd 7. /build/src/Processors/Executors/PipelineExecutor.cpp:206: DB::PipelineExecutor::finalizeExecution() @ 0x00000000169b13ba 8. /build/src/Processors/Executors/PipelineExecutor.cpp:153: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x00000000169b0584 9. /build/src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:se190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169bfeab 10. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc3d92 11. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fcca080 12. ? @ 0x00007fbc6213eac3 13. ? @ 0x00007fbc621d0850 Job's origin stack trace: 0. /build/src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000000fc33b84 1. /build/src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000000fcc2ea7 2. /build/src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fcc535c 3. /build/src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000000fcc584d 4. /build/src/Common/ThreadPool.h:279: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x00000000169bf193 5. /build/src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x00000000169bf518 6. /build/src/Server/TCPHandler.cpp:1237: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x00000000168f1525 7. /build/src/Server/TCPHandler.cpp:678: DB::TCPHandler::runImpl() @ 0x00000000168e68e5 8. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 9. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 10. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 11. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 12. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 13. ? @ 0x00007fbc6213eac3 14. ? @ 0x00007fbc621d0850 2025.07.28 12:02:27.237731 [ 17611 ] {} TCPHandler: Code: 394. DB::Exception: Query was cancelled. (QUERY_WAS_CANCELLED), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000000a074fcb 4. /build/src/Interpreters/ProcessList.cpp:567: DB::QueryStatus::throwQueryWasCancelled() const @ 0x0000000014a4bc85 5. /build/src/Interpreters/ProcessList.cpp:520: DB::QueryStatus::throwProperExceptionIfNeeded(unsigned long const&, unsigned long const&) @ 0x0000000014a4bbd9 6. /build/src/Interpreters/ProcessList.cpp:557: DB::QueryStatus::checkTimeLimit() @ 0x0000000014a4c2cd 7. /build/src/Processors/Executors/PipelineExecutor.cpp:206: DB::PipelineExecutor::finalizeExecution() @ 0x00000000169b13ba 8. /build/src/Processors/Executors/PipelineExecutor.cpp:181: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x00000000169b1726 9. /build/src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x00000000169c081c 10. /build/src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x00000000169c0978 11. /build/src/Interpreters/InterpreterKillQueryQuery.cpp:439: DB::InterpreterKillQueryQuery::getSelectResult(String const&, String const&) @ 0x0000000014cf0f04 12. /build/src/Interpreters/InterpreterKillQueryQuery.cpp:222: DB::InterpreterKillQueryQuery::execute() @ 0x0000000014cebde2 13. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88dc9 14. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 15. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 16. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 17. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 18. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 19. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 20. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 21. ? @ 0x00007fbc6213eac3 22. ? @ 0x00007fbc621d0850 2025.07.28 12:02:27.259295 [ 4446 ] {12ba589a-58a6-4ad4-8f3f-709d0d11dae5} executeQuery: Code: 394. DB::Exception: Query was cancelled. (QUERY_WAS_CANCELLED) (version 25.3.6.10636.altinitytest (altinity build)) (from [::1]:34834) (comment: 02461_cancel_finish_race.sh) (query 1, line 1) (in query: KILL QUERY WHERE current_database = 'test_dtwle8fg' SYNC FORMAT Null), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000000a074fcb 4. /build/src/Interpreters/ProcessList.cpp:567: DB::QueryStatus::throwQueryWasCancelled() const @ 0x0000000014a4bc85 5. /build/src/Interpreters/ProcessList.cpp:520: DB::QueryStatus::throwProperExceptionIfNeeded(unsigned long const&, unsigned long const&) @ 0x0000000014a4bbd9 6. /build/src/Interpreters/ProcessList.cpp:531: DB::QueryStatus::addPipelineExecutor(DB::PipelineExecutor*) @ 0x0000000014a4bd9c 7. /build/src/Processors/Executors/PipelineExecutor.cpp:73: DB::PipelineExecutor::PipelineExecutor(std::shared_ptr, std::allocator>>>&, std::shared_ptr) @ 0x00000000169afe31 8. /build/contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x00000000169bef66 9. /build/src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x00000000169bf518 10. /build/src/Server/TCPHandler.cpp:1237: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x00000000168f1525 11. /build/src/Server/TCPHandler.cpp:678: DB::TCPHandler::runImpl() @ 0x00000000168e68e5 12. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 13. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 14. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 16. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 17. ? @ 0x00007fbc6213eac3 18. ? @ 0x00007fbc621d0850 2025.07.28 12:02:27.271675 [ 4446 ] {} TCPHandler: Code: 394. DB::Exception: Query was cancelled. (QUERY_WAS_CANCELLED), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000000a074fcb 4. /build/src/Interpreters/ProcessList.cpp:567: DB::QueryStatus::throwQueryWasCancelled() const @ 0x0000000014a4bc85 5. /build/src/Interpreters/ProcessList.cpp:520: DB::QueryStatus::throwProperExceptionIfNeeded(unsigned long const&, unsigned long const&) @ 0x0000000014a4bbd9 6. /build/src/Interpreters/ProcessList.cpp:531: DB::QueryStatus::addPipelineExecutor(DB::PipelineExecutor*) @ 0x0000000014a4bd9c 7. /build/src/Processors/Executors/PipelineExecutor.cpp:73: DB::PipelineExecutor::PipelineExecutor(std::shared_ptr, std::allocator>>>&, std::shared_ptr) @ 0x00000000169afe31 8. /build/contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x00000000169bef66 9. /build/src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x00000000169bf518 10. /build/src/Server/TCPHandler.cpp:1237: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x00000000168f1525 11. /build/src/Server/TCPHandler.cpp:678: DB::TCPHandler::runImpl() @ 0x00000000168e68e5 12. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 13. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 14. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 16. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 17. ? @ 0x00007fbc6213eac3 18. ? @ 0x00007fbc621d0850 2025.07.28 12:02:27.271860 [ 5112 ] {458a21bc-8a80-414b-8bee-fb8d1a1235ae} executeQuery: Code: 394. DB::Exception: Query was cancelled. (QUERY_WAS_CANCELLED) (version 25.3.6.10636.altinitytest (altinity build)) (from [::1]:34884) (comment: 02461_cancel_finish_race.sh) (query 1, line 1) (in query: KILL QUERY WHERE current_database = 'test_dtwle8fg' SYNC FORMAT Null), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000000a074fcb 4. /build/src/Interpreters/ProcessList.cpp:567: DB::QueryStatus::throwQueryWasCancelled() const @ 0x0000000014a4bc85 5. /build/src/Interpreters/ProcessList.cpp:520: DB::QueryStatus::throwProperExceptionIfNeeded(unsigned long const&, unsigned long const&) @ 0x0000000014a4bbd9 6. /build/src/Interpreters/ProcessList.cpp:557: DB::QueryStatus::checkTimeLimit() @ 0x0000000014a4c2cd 7. /build/src/Processors/Executors/PipelineExecutor.cpp:206: DB::PipelineExecutor::finalizeExecution() @ 0x00000000169b13ba 8. /build/src/Processors/Executors/PipelineExecutor.cpp:153: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x00000000169b0584 9. /build/src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:se190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169bfeab 10. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc3d92 11. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fcca080 12. ? @ 0x00007fbc6213eac3 13. ? @ 0x00007fbc621d0850 2025.07.28 12:02:27.284334 [ 5112 ] {} TCPHandler: Code: 394. DB::Exception: Query was cancelled. (QUERY_WAS_CANCELLED), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000000a074fcb 4. /build/src/Interpreters/ProcessList.cpp:567: DB::QueryStatus::throwQueryWasCancelled() const @ 0x0000000014a4bc85 5. /build/src/Interpreters/ProcessList.cpp:520: DB::QueryStatus::throwProperExceptionIfNeeded(unsigned long const&, unsigned long const&) @ 0x0000000014a4bbd9 6. /build/src/Interpreters/ProcessList.cpp:557: DB::QueryStatus::checkTimeLimit() @ 0x0000000014a4c2cd 7. /build/src/Processors/Executors/PipelineExecutor.cpp:206: DB::PipelineExecutor::finalizeExecution() @ 0x00000000169b13ba 8. /build/src/Processors/Executors/PipelineExecutor.cpp:153: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x00000000169b0584 9. /build/src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:se190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169bfeab 10. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc3d92 11. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fcca080 12. ? @ 0x00007fbc6213eac3 13. ? @ 0x00007fbc621d0850 Job's origin stack trace: 0. /build/src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000000fc33b84 1. /build/src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000000fcc2ea7 2. /build/src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fcc535c 3. /build/src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000000fcc584d 4. /build/src/Common/ThreadPool.h:279: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x00000000169bf193 5. /build/src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x00000000169bf518 6. /build/src/Server/TCPHandler.cpp:1237: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x00000000168f1525 7. /build/src/Server/TCPHandler.cpp:678: DB::TCPHandler::runImpl() @ 0x00000000168e68e5 8. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 9. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 10. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 11. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 12. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 13. ? @ 0x00007fbc6213eac3 14. ? @ 0x00007fbc621d0850 2025.07.28 12:02:27.290221 [ 62055 ] {adabf9bb-9474-43a6-aa91-e79eb1c76166} executeQuery: Code: 394. DB::Exception: Query was cancelled. (QUERY_WAS_CANCELLED) (version 25.3.6.10636.altinitytest (altinity build)) (from [::1]:34904) (comment: 02461_cancel_finish_race.sh) (query 1, line 1) (in query: KILL QUERY WHERE current_database = 'test_dtwle8fg' SYNC FORMAT Null), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000000a074fcb 4. /build/src/Interpreters/ProcessList.cpp:567: DB::QueryStatus::throwQueryWasCancelled() const @ 0x0000000014a4bc85 5. /build/src/Interpreters/ProcessList.cpp:520: DB::QueryStatus::throwProperExceptionIfNeeded(unsigned long const&, unsigned long const&) @ 0x0000000014a4bbd9 6. /build/src/Interpreters/ProcessList.cpp:557: DB::QueryStatus::checkTimeLimit() @ 0x0000000014a4c2cd 7. /build/src/Processors/Executors/PipelineExecutor.cpp:206: DB::PipelineExecutor::finalizeExecution() @ 0x00000000169b13ba 8. /build/src/Processors/Executors/PipelineExecutor.cpp:153: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x00000000169b0584 9. /build/src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:se190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169bfeab 10. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc3d92 11. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fcca080 12. ? @ 0x00007fbc6213eac3 13. ? @ 0x00007fbc621d0850 2025.07.28 12:02:27.308399 [ 17243 ] {63c7bc82-0d9d-478f-9ab9-75658d9af114} executeQuery: Code: 394. DB::Exception: Query was cancelled. (QUERY_WAS_CANCELLED) (version 25.3.6.10636.altinitytest (altinity build)) (from [::1]:34858) (comment: 02461_cancel_finish_race.sh) (query 1, line 1) (in query: KILL QUERY WHERE current_database = 'test_dtwle8fg' SYNC FORMAT Null), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000000a074fcb 4. /build/src/Interpreters/ProcessList.cpp:567: DB::QueryStatus::throwQueryWasCancelled() const @ 0x0000000014a4bc85 5. /build/src/Interpreters/ProcessList.cpp:520: DB::QueryStatus::throwProperExceptionIfNeeded(unsigned long const&, unsigned long const&) @ 0x0000000014a4bbd9 6. /build/src/Interpreters/ProcessList.cpp:557: DB::QueryStatus::checkTimeLimit() @ 0x0000000014a4c2cd 7. /build/src/Processors/Executors/PipelineExecutor.cpp:206: DB::PipelineExecutor::finalizeExecution() @ 0x00000000169b13ba 8. /build/src/Processors/Executors/PipelineExecutor.cpp:153: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x00000000169b0584 9. /build/src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:se190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169bfeab 10. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc3d92 11. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fcca080 12. ? @ 0x00007fbc6213eac3 13. ? @ 0x00007fbc621d0850 2025.07.28 12:02:27.308450 [ 62055 ] {} TCPHandler: Code: 394. DB::Exception: Query was cancelled. (QUERY_WAS_CANCELLED), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000000a074fcb 4. /build/src/Interpreters/ProcessList.cpp:567: DB::QueryStatus::throwQueryWasCancelled() const @ 0x0000000014a4bc85 5. /build/src/Interpreters/ProcessList.cpp:520: DB::QueryStatus::throwProperExceptionIfNeeded(unsigned long const&, unsigned long const&) @ 0x0000000014a4bbd9 6. /build/src/Interpreters/ProcessList.cpp:557: DB::QueryStatus::checkTimeLimit() @ 0x0000000014a4c2cd 7. /build/src/Processors/Executors/PipelineExecutor.cpp:206: DB::PipelineExecutor::finalizeExecution() @ 0x00000000169b13ba 8. /build/src/Processors/Executors/PipelineExecutor.cpp:153: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x00000000169b0584 9. /build/src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:se190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169bfeab 10. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc3d92 11. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fcca080 12. ? @ 0x00007fbc6213eac3 13. ? @ 0x00007fbc621d0850 Job's origin stack trace: 0. /build/src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000000fc33b84 1. /build/src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000000fcc2ea7 2. /build/src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fcc535c 3. /build/src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000000fcc584d 4. /build/src/Common/ThreadPool.h:279: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x00000000169bf193 5. /build/src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x00000000169bf518 6. /build/src/Server/TCPHandler.cpp:1237: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x00000000168f1525 7. /build/src/Server/TCPHandler.cpp:678: DB::TCPHandler::runImpl() @ 0x00000000168e68e5 8. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 9. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 10. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 11. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 12. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 13. ? @ 0x00007fbc6213eac3 14. ? @ 0x00007fbc621d0850 2025.07.28 12:02:27.308054 [ 62093 ] {e74b95c4-e56f-4a49-9c0d-7095a4745d04} executeQuery: Code: 394. DB::Exception: Query was cancelled. (QUERY_WAS_CANCELLED) (version 25.3.6.10636.altinitytest (altinity build)) (from [::1]:34910) (comment: 02461_cancel_finish_race.sh) (query 1, line 1) (in query: KILL QUERY WHERE current_database = 'test_dtwle8fg' SYNC FORMAT Null), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000000a074fcb 4. /build/src/Interpreters/ProcessList.cpp:567: DB::QueryStatus::throwQueryWasCancelled() const @ 0x0000000014a4bc85 5. /build/src/Interpreters/ProcessList.cpp:520: DB::QueryStatus::throwProperExceptionIfNeeded(unsigned long const&, unsigned long const&) @ 0x0000000014a4bbd9 6. /build/src/Interpreters/ProcessList.cpp:557: DB::QueryStatus::checkTimeLimit() @ 0x0000000014a4c2cd 7. /build/src/Processors/Executors/PipelineExecutor.cpp:206: DB::PipelineExecutor::finalizeExecution() @ 0x00000000169b13ba 8. /build/src/Processors/Executors/PipelineExecutor.cpp:153: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x00000000169b0584 9. /build/src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:se190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169bfeab 10. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc3d92 11. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fcca080 12. ? @ 0x00007fbc6213eac3 13. ? @ 0x00007fbc621d0850 2025.07.28 12:02:27.321076 [ 17243 ] {} TCPHandler: Code: 394. DB::Exception: Query was cancelled. (QUERY_WAS_CANCELLED), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000000a074fcb 4. /build/src/Interpreters/ProcessList.cpp:567: DB::QueryStatus::throwQueryWasCancelled() const @ 0x0000000014a4bc85 5. /build/src/Interpreters/ProcessList.cpp:520: DB::QueryStatus::throwProperExceptionIfNeeded(unsigned long const&, unsigned long const&) @ 0x0000000014a4bbd9 6. /build/src/Interpreters/ProcessList.cpp:557: DB::QueryStatus::checkTimeLimit() @ 0x0000000014a4c2cd 7. /build/src/Processors/Executors/PipelineExecutor.cpp:206: DB::PipelineExecutor::finalizeExecution() @ 0x00000000169b13ba 8. /build/src/Processors/Executors/PipelineExecutor.cpp:153: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x00000000169b0584 9. /build/src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:se190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169bfeab 10. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc3d92 11. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fcca080 12. ? @ 0x00007fbc6213eac3 13. ? @ 0x00007fbc621d0850 Job's origin stack trace: 0. /build/src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000000fc33b84 1. /build/src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000000fcc2ea7 2. /build/src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fcc535c 3. /build/src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000000fcc584d 4. /build/src/Common/ThreadPool.h:279: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x00000000169bf193 5. /build/src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x00000000169bf518 6. /build/src/Server/TCPHandler.cpp:1237: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x00000000168f1525 7. /build/src/Server/TCPHandler.cpp:678: DB::TCPHandler::runImpl() @ 0x00000000168e68e5 8. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 9. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 10. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 11. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 12. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 13. ? @ 0x00007fbc6213eac3 14. ? @ 0x00007fbc621d0850 2025.07.28 12:02:27.386124 [ 62093 ] {} TCPHandler: Code: 394. DB::Exception: Query was cancelled. (QUERY_WAS_CANCELLED), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000000a074fcb 4. /build/src/Interpreters/ProcessList.cpp:567: DB::QueryStatus::throwQueryWasCancelled() const @ 0x0000000014a4bc85 5. /build/src/Interpreters/ProcessList.cpp:520: DB::QueryStatus::throwProperExceptionIfNeeded(unsigned long const&, unsigned long const&) @ 0x0000000014a4bbd9 6. /build/src/Interpreters/ProcessList.cpp:557: DB::QueryStatus::checkTimeLimit() @ 0x0000000014a4c2cd 7. /build/src/Processors/Executors/PipelineExecutor.cpp:206: DB::PipelineExecutor::finalizeExecution() @ 0x00000000169b13ba 8. /build/src/Processors/Executors/PipelineExecutor.cpp:153: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x00000000169b0584 9. /build/src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:se190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169bfeab 10. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc3d92 11. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fcca080 12. ? @ 0x00007fbc6213eac3 13. ? @ 0x00007fbc621d0850 Job's origin stack trace: 0. /build/src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000000fc33b84 1. /build/src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000000fcc2ea7 2. /build/src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fcc535c 3. /build/src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000000fcc584d 4. /build/src/Common/ThreadPool.h:279: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x00000000169bf193 5. /build/src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x00000000169bf518 6. /build/src/Server/TCPHandler.cpp:1237: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x00000000168f1525 7. /build/src/Server/TCPHandler.cpp:678: DB::TCPHandler::runImpl() @ 0x00000000168e68e5 8. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 9. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 10. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 11. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 12. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 13. ? @ 0x00007fbc6213eac3 14. ? @ 0x00007fbc621d0850 2025.07.28 12:02:27.598507 [ 62058 ] {} TCPHandler: Code: 394. DB::Exception: Query was cancelled. (QUERY_WAS_CANCELLED), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000000a074fcb 4. /build/src/Interpreters/ProcessList.cpp:567: DB::QueryStatus::throwQueryWasCancelled() const @ 0x0000000014a4bc85 5. /build/src/Interpreters/ProcessList.cpp:520: DB::QueryStatus::throwProperExceptionIfNeeded(unsigned long const&, unsigned long const&) @ 0x0000000014a4bbd9 6. /build/src/Interpreters/ProcessList.cpp:557: DB::QueryStatus::checkTimeLimit() @ 0x0000000014a4c2cd 7. /build/src/Processors/Executors/PipelineExecutor.cpp:206: DB::PipelineExecutor::finalizeExecution() @ 0x00000000169b13ba 8. /build/src/Processors/Executors/PipelineExecutor.cpp:181: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x00000000169b1726 9. /build/src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x00000000169c081c 10. /build/src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x00000000169c0978 11. /build/src/Interpreters/InterpreterKillQueryQuery.cpp:439: DB::InterpreterKillQueryQuery::getSelectResult(String const&, String const&) @ 0x0000000014cf0f04 12. /build/src/Interpreters/InterpreterKillQueryQuery.cpp:222: DB::InterpreterKillQueryQuery::execute() @ 0x0000000014cebde2 13. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88dc9 14. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 15. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 16. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 17. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 18. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 19. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 20. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 21. ? @ 0x00007fbc6213eac3 22. ? @ 0x00007fbc621d0850 2025.07.28 12:02:27.674342 [ 3964 ] {} test_13.rmt2 (7f9b740d-015c-470e-8cc6-8ba33be0dc63): auto DB::StorageReplicatedMergeTree::processQueueEntry(ReplicatedMergeTreeQueue::SelectedEntryPtr)::(anonymous class)::operator()(LogEntryPtr &) const: Code: 86. DB::HTTPException: Received error from remote server http://146b4357c08d:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Ftest%2F01165%2Ftest_13%2Frmt%2Freplicas%2F1&part=20250728_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.6.10636.altinitytest (altinity build)) '. (RECEIVED_ERROR_FROM_REMOTE_IO_SERVER), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.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 const&, int&&, String const&, unsigned long&&, String const&) @ 0x000000000feda8d9 4. /build/src/IO/HTTPCommon.cpp:104: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x000000000feda6e2 5. /build/src/IO/HTTPCommon.cpp:93: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x000000000feda537 6. /build/src/IO/ReadWriteBufferFromHTTP.cpp:277: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x000000001184a4c4 7. /build/src/IO/ReadWriteBufferFromHTTP.cpp:285: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x000000001184a615 8. /build/src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x000000001184ae59 9. /build/src/IO/ReadWriteBufferFromHTTP.cpp:472: void std::__function::__policy_invoker::__call_impl[abi:se190107]>(std::__function::__policy_storage const*) @ 0x000000001184cedd 10. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001184858b 11. /build/src/IO/ReadWriteBufferFromHTTP.cpp:465: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x000000001184bf0b 12. /build/src/IO/ReadBuffer.h:60: DB::ReadBuffer::next() @ 0x000000000a148c7b 13. /build/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) @ 0x0000000011849fb2 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]>&)>&, 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&) @ 0x0000000011841980 15. /build/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) @ 0x000000001621208e 16. /build/src/Storages/StorageReplicatedMergeTree.cpp:5228: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl[abi:se190107] const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000015f9a5fe 17. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000015ed8bfd 18. /build/src/Storages/StorageReplicatedMergeTree.cpp:2514: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x0000000015ec9aab 19. /build/src/Storages/StorageReplicatedMergeTree.cpp:2349: DB::StorageReplicatedMergeTree::executeLogEntry(DB::ReplicatedMergeTreeLogEntry&) @ 0x0000000015eba91b 20. /build/src/Storages/StorageReplicatedMergeTree.cpp:3876: bool std::__function::__policy_invoker&)>::__call_impl[abi:se190107])::$_1, bool (std::shared_ptr&)>>(std::__function::__policy_storage const*, std::shared_ptr&) @ 0x0000000015f9837e 21. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000165d6fc3 22. /build/src/Storages/StorageReplicatedMergeTree.cpp:3872: DB::StorageReplicatedMergeTree::processQueueEntry(std::shared_ptr) @ 0x0000000015efc18a 23. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001624c1b2 24. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000162f9c70 25. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x00000000162fa55a 26. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc6653 27. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000000fccc4c3 28. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc3d92 29. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fcca080 30. ? @ 0x00007fbc6213eac3 31. ? @ 0x00007fbc621d0850 (version 25.3.6.10636.altinitytest (altinity build)) 2025.07.28 12:02:27.790477 [ 62055 ] {} TCPHandler: Code: 394. DB::Exception: Query '5ca14845-f730-4e67-8932-6dfed8e3122b' is killed in pending state. (QUERY_WAS_CANCELLED), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x000000000a06b56b 4. /build/src/Interpreters/executeQuery.cpp:1522: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c8a4ef 5. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 6. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 7. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 8. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 9. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 10. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 11. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 12. ? @ 0x00007fbc6213eac3 13. ? @ 0x00007fbc621d0850 2025.07.28 12:02:27.948444 [ 5112 ] {} TCPHandler: Code: 394. DB::Exception: Query was cancelled. (QUERY_WAS_CANCELLED), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000000a074fcb 4. /build/src/Interpreters/ProcessList.cpp:567: DB::QueryStatus::throwQueryWasCancelled() const @ 0x0000000014a4bc85 5. /build/src/Interpreters/ProcessList.cpp:520: DB::QueryStatus::throwProperExceptionIfNeeded(unsigned long const&, unsigned long const&) @ 0x0000000014a4bbd9 6. /build/src/Interpreters/ProcessList.cpp:557: DB::QueryStatus::checkTimeLimit() @ 0x0000000014a4c2cd 7. /build/src/Processors/Executors/PipelineExecutor.cpp:206: DB::PipelineExecutor::finalizeExecution() @ 0x00000000169b13ba 8. /build/src/Processors/Executors/PipelineExecutor.cpp:181: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x00000000169b1726 9. /build/src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x00000000169c081c 10. /build/src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x00000000169c0978 11. /build/src/Interpreters/InterpreterKillQueryQuery.cpp:442: DB::InterpreterKillQueryQuery::getSelectResult(String const&, String const&) @ 0x0000000014cf0f6b 12. /build/src/Interpreters/InterpreterKillQueryQuery.cpp:222: DB::InterpreterKillQueryQuery::execute() @ 0x0000000014cebde2 13. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88dc9 14. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 15. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 16. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 17. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 18. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 19. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 20. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 21. ? @ 0x00007fbc6213eac3 22. ? @ 0x00007fbc621d0850 2025.07.28 12:02:27.972738 [ 3965 ] {} test_13.rmt2 (7f9b740d-015c-470e-8cc6-8ba33be0dc63): auto DB::StorageReplicatedMergeTree::processQueueEntry(ReplicatedMergeTreeQueue::SelectedEntryPtr)::(anonymous class)::operator()(LogEntryPtr &) const: Code: 86. DB::HTTPException: Received error from remote server http://146b4357c08d:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Ftest%2F01165%2Ftest_13%2Frmt%2Freplicas%2F1&part=20250728_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.6.10636.altinitytest (altinity build)) '. (RECEIVED_ERROR_FROM_REMOTE_IO_SERVER), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.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 const&, int&&, String const&, unsigned long&&, String const&) @ 0x000000000feda8d9 4. /build/src/IO/HTTPCommon.cpp:104: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x000000000feda6e2 5. /build/src/IO/HTTPCommon.cpp:93: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x000000000feda537 6. /build/src/IO/ReadWriteBufferFromHTTP.cpp:277: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x000000001184a4c4 7. /build/src/IO/ReadWriteBufferFromHTTP.cpp:285: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x000000001184a615 8. /build/src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x000000001184ae59 9. /build/src/IO/ReadWriteBufferFromHTTP.cpp:472: void std::__function::__policy_invoker::__call_impl[abi:se190107]>(std::__function::__policy_storage const*) @ 0x000000001184cedd 10. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001184858b 11. /build/src/IO/ReadWriteBufferFromHTTP.cpp:465: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x000000001184bf0b 12. /build/src/IO/ReadBuffer.h:60: DB::ReadBuffer::next() @ 0x000000000a148c7b 13. /build/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) @ 0x0000000011849fb2 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]>&)>&, 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&) @ 0x0000000011841980 15. /build/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) @ 0x000000001621208e 16. /build/src/Storages/StorageReplicatedMergeTree.cpp:5228: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl[abi:se190107] const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000015f9a5fe 17. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000015ed8bfd 18. /build/src/Storages/StorageReplicatedMergeTree.cpp:2514: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x0000000015ec9aab 19. /build/src/Storages/StorageReplicatedMergeTree.cpp:2349: DB::StorageReplicatedMergeTree::executeLogEntry(DB::ReplicatedMergeTreeLogEntry&) @ 0x0000000015eba91b 20. /build/src/Storages/StorageReplicatedMergeTree.cpp:3876: bool std::__function::__policy_invoker&)>::__call_impl[abi:se190107])::$_1, bool (std::shared_ptr&)>>(std::__function::__policy_storage const*, std::shared_ptr&) @ 0x0000000015f9837e 21. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000165d6fc3 22. /build/src/Storages/StorageReplicatedMergeTree.cpp:3872: DB::StorageReplicatedMergeTree::processQueueEntry(std::shared_ptr) @ 0x0000000015efc18a 23. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001624c1b2 24. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000162f9c70 25. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x00000000162fa55a 26. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc6653 27. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000000fccc4c3 28. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc3d92 29. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fcca080 30. ? @ 0x00007fbc6213eac3 31. ? @ 0x00007fbc621d0850 (version 25.3.6.10636.altinitytest (altinity build)) 2025.07.28 12:02:28.073486 [ 62056 ] {b3a6ac80-c5d6-490a-a30b-a208316ed6cc} executeQuery: Code: 394. DB::Exception: Query was cancelled. (QUERY_WAS_CANCELLED) (version 25.3.6.10636.altinitytest (altinity build)) (from [::1]:35104) (comment: 02461_cancel_finish_race.sh) (query 1, line 1) (in query: KILL QUERY WHERE current_database = 'test_dtwle8fg' SYNC FORMAT Null), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000000a074fcb 4. /build/src/Interpreters/ProcessList.cpp:567: DB::QueryStatus::throwQueryWasCancelled() const @ 0x0000000014a4bc85 5. /build/src/Interpreters/ProcessList.cpp:520: DB::QueryStatus::throwProperExceptionIfNeeded(unsigned long const&, unsigned long const&) @ 0x0000000014a4bbd9 6. /build/src/Interpreters/ProcessList.cpp:557: DB::QueryStatus::checkTimeLimit() @ 0x0000000014a4c2cd 7. /build/src/Processors/Executors/PipelineExecutor.cpp:206: DB::PipelineExecutor::finalizeExecution() @ 0x00000000169b13ba 8. /build/src/Processors/Executors/PipelineExecutor.cpp:153: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x00000000169b0584 9. /build/src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:se190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169bfeab 10. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc3d92 11. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fcca080 12. ? @ 0x00007fbc6213eac3 13. ? @ 0x00007fbc621d0850 2025.07.28 12:02:28.073607 [ 4900 ] {b59c19e1-6e05-4663-9f11-e3965ae93894} executeQuery: Code: 394. DB::Exception: Query was cancelled. (QUERY_WAS_CANCELLED) (version 25.3.6.10636.altinitytest (altinity build)) (from [::1]:35178) (comment: 02461_cancel_finish_race.sh) (query 1, line 1) (in query: KILL QUERY WHERE current_database = 'test_dtwle8fg' SYNC FORMAT Null), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000000a074fcb 4. /build/src/Interpreters/ProcessList.cpp:567: DB::QueryStatus::throwQueryWasCancelled() const @ 0x0000000014a4bc85 5. /build/src/Interpreters/ProcessList.cpp:520: DB::QueryStatus::throwProperExceptionIfNeeded(unsigned long const&, unsigned long const&) @ 0x0000000014a4bbd9 6. /build/src/Interpreters/ProcessList.cpp:557: DB::QueryStatus::checkTimeLimit() @ 0x0000000014a4c2cd 7. /build/src/Processors/Executors/PipelineExecutor.cpp:206: DB::PipelineExecutor::finalizeExecution() @ 0x00000000169b13ba 8. /build/src/Processors/Executors/PipelineExecutor.cpp:153: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x00000000169b0584 9. /build/src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:se190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169bfeab 10. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc3d92 11. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fcca080 12. ? @ 0x00007fbc6213eac3 13. ? @ 0x00007fbc621d0850 2025.07.28 12:02:28.073414 [ 17243 ] {c6a105cc-3cde-4611-b07e-b5d02091f7e3} executeQuery: Code: 394. DB::Exception: Query was cancelled. (QUERY_WAS_CANCELLED) (version 25.3.6.10636.altinitytest (altinity build)) (from [::1]:35146) (comment: 02461_cancel_finish_race.sh) (query 1, line 1) (in query: KILL QUERY WHERE current_database = 'test_dtwle8fg' SYNC FORMAT Null), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000000a074fcb 4. /build/src/Interpreters/ProcessList.cpp:567: DB::QueryStatus::throwQueryWasCancelled() const @ 0x0000000014a4bc85 5. /build/src/Interpreters/ProcessList.cpp:520: DB::QueryStatus::throwProperExceptionIfNeeded(unsigned long const&, unsigned long const&) @ 0x0000000014a4bbd9 6. /build/src/Interpreters/ProcessList.cpp:557: DB::QueryStatus::checkTimeLimit() @ 0x0000000014a4c2cd 7. /build/src/Processors/Executors/PipelineExecutor.cpp:206: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x00000000169b03a3 8. /build/src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:se190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169bfeab 9. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc3d92 10. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fcca080 11. ? @ 0x00007fbc6213eac3 12. ? @ 0x00007fbc621d0850 2025.07.28 12:02:28.094523 [ 62056 ] {} TCPHandler: Code: 394. DB::Exception: Query was cancelled. (QUERY_WAS_CANCELLED), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000000a074fcb 4. /build/src/Interpreters/ProcessList.cpp:567: DB::QueryStatus::throwQueryWasCancelled() const @ 0x0000000014a4bc85 5. /build/src/Interpreters/ProcessList.cpp:520: DB::QueryStatus::throwProperExceptionIfNeeded(unsigned long const&, unsigned long const&) @ 0x0000000014a4bbd9 6. /build/src/Interpreters/ProcessList.cpp:557: DB::QueryStatus::checkTimeLimit() @ 0x0000000014a4c2cd 7. /build/src/Processors/Executors/PipelineExecutor.cpp:206: DB::PipelineExecutor::finalizeExecution() @ 0x00000000169b13ba 8. /build/src/Processors/Executors/PipelineExecutor.cpp:153: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x00000000169b0584 9. /build/src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:se190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169bfeab 10. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc3d92 11. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fcca080 12. ? @ 0x00007fbc6213eac3 13. ? @ 0x00007fbc621d0850 Job's origin stack trace: 0. /build/src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000000fc33b84 1. /build/src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000000fcc2ea7 2. /build/src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fcc535c 3. /build/src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000000fcc584d 4. /build/src/Common/ThreadPool.h:279: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x00000000169bf193 5. /build/src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x00000000169bf518 6. /build/src/Server/TCPHandler.cpp:1237: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x00000000168f1525 7. /build/src/Server/TCPHandler.cpp:678: DB::TCPHandler::runImpl() @ 0x00000000168e68e5 8. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 9. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 10. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 11. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 12. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 13. ? @ 0x00007fbc6213eac3 14. ? @ 0x00007fbc621d0850 2025.07.28 12:02:28.094732 [ 4900 ] {} TCPHandler: Code: 394. DB::Exception: Query was cancelled. (QUERY_WAS_CANCELLED), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000000a074fcb 4. /build/src/Interpreters/ProcessList.cpp:567: DB::QueryStatus::throwQueryWasCancelled() const @ 0x0000000014a4bc85 5. /build/src/Interpreters/ProcessList.cpp:520: DB::QueryStatus::throwProperExceptionIfNeeded(unsigned long const&, unsigned long const&) @ 0x0000000014a4bbd9 6. /build/src/Interpreters/ProcessList.cpp:557: DB::QueryStatus::checkTimeLimit() @ 0x0000000014a4c2cd 7. /build/src/Processors/Executors/PipelineExecutor.cpp:206: DB::PipelineExecutor::finalizeExecution() @ 0x00000000169b13ba 8. /build/src/Processors/Executors/PipelineExecutor.cpp:153: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x00000000169b0584 9. /build/src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:se190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169bfeab 10. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc3d92 11. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fcca080 12. ? @ 0x00007fbc6213eac3 13. ? @ 0x00007fbc621d0850 Job's origin stack trace: 0. /build/src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000000fc33b84 1. /build/src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000000fcc2ea7 2. /build/src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fcc535c 3. /build/src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000000fcc584d 4. /build/src/Common/ThreadPool.h:279: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x00000000169bf193 5. /build/src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x00000000169bf518 6. /build/src/Server/TCPHandler.cpp:1237: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x00000000168f1525 7. /build/src/Server/TCPHandler.cpp:678: DB::TCPHandler::runImpl() @ 0x00000000168e68e5 8. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 9. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 10. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 11. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 12. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 13. ? @ 0x00007fbc6213eac3 14. ? @ 0x00007fbc621d0850 2025.07.28 12:02:28.111929 [ 17243 ] {} TCPHandler: Code: 394. DB::Exception: Query was cancelled. (QUERY_WAS_CANCELLED), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000000a074fcb 4. /build/src/Interpreters/ProcessList.cpp:567: DB::QueryStatus::throwQueryWasCancelled() const @ 0x0000000014a4bc85 5. /build/src/Interpreters/ProcessList.cpp:520: DB::QueryStatus::throwProperExceptionIfNeeded(unsigned long const&, unsigned long const&) @ 0x0000000014a4bbd9 6. /build/src/Interpreters/ProcessList.cpp:557: DB::QueryStatus::checkTimeLimit() @ 0x0000000014a4c2cd 7. /build/src/Processors/Executors/PipelineExecutor.cpp:206: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x00000000169b03a3 8. /build/src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:se190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169bfeab 9. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc3d92 10. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fcca080 11. ? @ 0x00007fbc6213eac3 12. ? @ 0x00007fbc621d0850 Job's origin stack trace: 0. /build/src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000000fc33b84 1. /build/src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000000fcc2ea7 2. /build/src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fcc535c 3. /build/src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000000fcc584d 4. /build/src/Common/ThreadPool.h:279: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x00000000169bf193 5. /build/src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x00000000169bf518 6. /build/src/Server/TCPHandler.cpp:1237: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x00000000168f1525 7. /build/src/Server/TCPHandler.cpp:678: DB::TCPHandler::runImpl() @ 0x00000000168e68e5 8. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 9. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 10. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 11. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 12. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 13. ? @ 0x00007fbc6213eac3 14. ? @ 0x00007fbc621d0850 2025.07.28 12:02:28.120767 [ 63425 ] {8363ec6c-1087-4458-848e-f9205b2126ec} executeQuery: Code: 394. DB::Exception: Query was cancelled. (QUERY_WAS_CANCELLED) (version 25.3.6.10636.altinitytest (altinity build)) (from [::1]:35180) (comment: 02461_cancel_finish_race.sh) (query 1, line 1) (in query: KILL QUERY WHERE current_database = 'test_dtwle8fg' SYNC FORMAT Null), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000000a074fcb 4. /build/src/Interpreters/ProcessList.cpp:567: DB::QueryStatus::throwQueryWasCancelled() const @ 0x0000000014a4bc85 5. /build/src/Interpreters/ProcessList.cpp:520: DB::QueryStatus::throwProperExceptionIfNeeded(unsigned long const&, unsigned long const&) @ 0x0000000014a4bbd9 6. /build/src/Interpreters/ProcessList.cpp:557: DB::QueryStatus::checkTimeLimit() @ 0x0000000014a4c2cd 7. /build/src/Processors/Executors/PipelineExecutor.cpp:206: DB::PipelineExecutor::finalizeExecution() @ 0x00000000169b13ba 8. /build/src/Processors/Executors/PipelineExecutor.cpp:153: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x00000000169b0584 9. /build/src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:se190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169bfeab 10. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc3d92 11. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fcca080 12. ? @ 0x00007fbc6213eac3 13. ? @ 0x00007fbc621d0850 2025.07.28 12:02:28.197729 [ 63425 ] {} TCPHandler: Code: 394. DB::Exception: Query was cancelled. (QUERY_WAS_CANCELLED), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000000a074fcb 4. /build/src/Interpreters/ProcessList.cpp:567: DB::QueryStatus::throwQueryWasCancelled() const @ 0x0000000014a4bc85 5. /build/src/Interpreters/ProcessList.cpp:520: DB::QueryStatus::throwProperExceptionIfNeeded(unsigned long const&, unsigned long const&) @ 0x0000000014a4bbd9 6. /build/src/Interpreters/ProcessList.cpp:557: DB::QueryStatus::checkTimeLimit() @ 0x0000000014a4c2cd 7. /build/src/Processors/Executors/PipelineExecutor.cpp:206: DB::PipelineExecutor::finalizeExecution() @ 0x00000000169b13ba 8. /build/src/Processors/Executors/PipelineExecutor.cpp:153: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x00000000169b0584 9. /build/src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:se190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169bfeab 10. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc3d92 11. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fcca080 12. ? @ 0x00007fbc6213eac3 13. ? @ 0x00007fbc621d0850 Job's origin stack trace: 0. /build/src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000000fc33b84 1. /build/src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000000fcc2ea7 2. /build/src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fcc535c 3. /build/src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000000fcc584d 4. /build/src/Common/ThreadPool.h:279: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x00000000169bf193 5. /build/src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x00000000169bf518 6. /build/src/Server/TCPHandler.cpp:1237: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x00000000168f1525 7. /build/src/Server/TCPHandler.cpp:678: DB::TCPHandler::runImpl() @ 0x00000000168e68e5 8. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 9. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 10. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 11. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 12. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 13. ? @ 0x00007fbc6213eac3 14. ? @ 0x00007fbc621d0850 2025.07.28 12:02:28.258743 [ 4963 ] {} TCPHandler: Code: 394. DB::Exception: Query was cancelled. (QUERY_WAS_CANCELLED), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000000a074fcb 4. /build/src/Interpreters/ProcessList.cpp:567: DB::QueryStatus::throwQueryWasCancelled() const @ 0x0000000014a4bc85 5. /build/src/Interpreters/ProcessList.cpp:520: DB::QueryStatus::throwProperExceptionIfNeeded(unsigned long const&, unsigned long const&) @ 0x0000000014a4bbd9 6. /build/src/Interpreters/ProcessList.cpp:531: DB::QueryStatus::addPipelineExecutor(DB::PipelineExecutor*) @ 0x0000000014a4bd9c 7. /build/src/Processors/Executors/PipelineExecutor.cpp:73: DB::PipelineExecutor::PipelineExecutor(std::shared_ptr, std::allocator>>>&, std::shared_ptr) @ 0x00000000169afe31 8. /build/contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x00000000169c07b5 9. /build/src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x00000000169c0978 10. /build/src/Interpreters/InterpreterKillQueryQuery.cpp:439: DB::InterpreterKillQueryQuery::getSelectResult(String const&, String const&) @ 0x0000000014cf0f04 11. /build/src/Interpreters/InterpreterKillQueryQuery.cpp:222: DB::InterpreterKillQueryQuery::execute() @ 0x0000000014cebde2 12. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88dc9 13. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 14. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 15. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 16. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 17. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 18. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 19. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 20. ? @ 0x00007fbc6213eac3 21. ? @ 0x00007fbc621d0850 2025.07.28 12:02:28.284069 [ 4446 ] {d2cdd2e1-267f-4cd4-a15a-84faac1ca9a1} executeQuery: Code: 394. DB::Exception: Query was cancelled. (QUERY_WAS_CANCELLED) (version 25.3.6.10636.altinitytest (altinity build)) (from [::1]:35286) (comment: 02461_cancel_finish_race.sh) (query 1, line 1) (in query: KILL QUERY WHERE current_database = 'test_dtwle8fg' SYNC FORMAT Null), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000000a074fcb 4. /build/src/Interpreters/ProcessList.cpp:567: DB::QueryStatus::throwQueryWasCancelled() const @ 0x0000000014a4bc85 5. /build/src/Interpreters/ProcessList.cpp:520: DB::QueryStatus::throwProperExceptionIfNeeded(unsigned long const&, unsigned long const&) @ 0x0000000014a4bbd9 6. /build/src/Interpreters/ProcessList.cpp:557: DB::QueryStatus::checkTimeLimit() @ 0x0000000014a4c2cd 7. /build/src/Processors/Executors/PipelineExecutor.cpp:206: DB::PipelineExecutor::finalizeExecution() @ 0x00000000169b13ba 8. /build/src/Processors/Executors/PipelineExecutor.cpp:153: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x00000000169b0584 9. /build/src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:se190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169bfeab 10. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc3d92 11. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fcca080 12. ? @ 0x00007fbc6213eac3 13. ? @ 0x00007fbc621d0850 2025.07.28 12:02:28.304421 [ 4446 ] {} TCPHandler: Code: 394. DB::Exception: Query was cancelled. (QUERY_WAS_CANCELLED), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000000a074fcb 4. /build/src/Interpreters/ProcessList.cpp:567: DB::QueryStatus::throwQueryWasCancelled() const @ 0x0000000014a4bc85 5. /build/src/Interpreters/ProcessList.cpp:520: DB::QueryStatus::throwProperExceptionIfNeeded(unsigned long const&, unsigned long const&) @ 0x0000000014a4bbd9 6. /build/src/Interpreters/ProcessList.cpp:557: DB::QueryStatus::checkTimeLimit() @ 0x0000000014a4c2cd 7. /build/src/Processors/Executors/PipelineExecutor.cpp:206: DB::PipelineExecutor::finalizeExecution() @ 0x00000000169b13ba 8. /build/src/Processors/Executors/PipelineExecutor.cpp:153: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x00000000169b0584 9. /build/src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:se190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169bfeab 10. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc3d92 11. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fcca080 12. ? @ 0x00007fbc6213eac3 13. ? @ 0x00007fbc621d0850 Job's origin stack trace: 0. /build/src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000000fc33b84 1. /build/src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000000fcc2ea7 2. /build/src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fcc535c 3. /build/src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000000fcc584d 4. /build/src/Common/ThreadPool.h:279: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x00000000169bf193 5. /build/src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x00000000169bf518 6. /build/src/Server/TCPHandler.cpp:1237: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x00000000168f1525 7. /build/src/Server/TCPHandler.cpp:678: DB::TCPHandler::runImpl() @ 0x00000000168e68e5 8. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 9. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 10. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 11. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 12. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 13. ? @ 0x00007fbc6213eac3 14. ? @ 0x00007fbc621d0850 2025.07.28 12:02:28.367513 [ 62075 ] {} TCPHandler: Code: 394. DB::Exception: Query was cancelled. (QUERY_WAS_CANCELLED), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000000a074fcb 4. /build/src/Interpreters/ProcessList.cpp:567: DB::QueryStatus::throwQueryWasCancelled() const @ 0x0000000014a4bc85 5. /build/src/Interpreters/ProcessList.cpp:520: DB::QueryStatus::throwProperExceptionIfNeeded(unsigned long const&, unsigned long const&) @ 0x0000000014a4bbd9 6. /build/src/Interpreters/ProcessList.cpp:531: DB::QueryStatus::addPipelineExecutor(DB::PipelineExecutor*) @ 0x0000000014a4bd9c 7. /build/src/Processors/Executors/PipelineExecutor.cpp:73: DB::PipelineExecutor::PipelineExecutor(std::shared_ptr, std::allocator>>>&, std::shared_ptr) @ 0x00000000169afe31 8. /build/contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x00000000169c07b5 9. /build/src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x00000000169c0978 10. /build/src/Interpreters/InterpreterKillQueryQuery.cpp:439: DB::InterpreterKillQueryQuery::getSelectResult(String const&, String const&) @ 0x0000000014cf0f04 11. /build/src/Interpreters/InterpreterKillQueryQuery.cpp:222: DB::InterpreterKillQueryQuery::execute() @ 0x0000000014cebde2 12. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88dc9 13. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 14. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 15. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 16. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 17. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 18. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 19. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 20. ? @ 0x00007fbc6213eac3 21. ? @ 0x00007fbc621d0850 2025.07.28 12:02:28.403636 [ 62057 ] {2cc7d8ce-494f-4292-995d-4c55d36c3206} executeQuery: Code: 394. DB::Exception: Query was cancelled. (QUERY_WAS_CANCELLED) (version 25.3.6.10636.altinitytest (altinity build)) (from [::1]:35292) (comment: 02461_cancel_finish_race.sh) (query 1, line 1) (in query: KILL QUERY WHERE current_database = 'test_dtwle8fg' SYNC FORMAT Null), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000000a074fcb 4. /build/src/Interpreters/ProcessList.cpp:567: DB::QueryStatus::throwQueryWasCancelled() const @ 0x0000000014a4bc85 5. /build/src/Interpreters/ProcessList.cpp:520: DB::QueryStatus::throwProperExceptionIfNeeded(unsigned long const&, unsigned long const&) @ 0x0000000014a4bbd9 6. /build/src/Interpreters/ProcessList.cpp:557: DB::QueryStatus::checkTimeLimit() @ 0x0000000014a4c2cd 7. /build/src/Processors/Executors/PipelineExecutor.cpp:206: DB::PipelineExecutor::finalizeExecution() @ 0x00000000169b13ba 8. /build/src/Processors/Executors/PipelineExecutor.cpp:153: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x00000000169b0584 9. /build/src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:se190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169bfeab 10. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc3d92 11. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fcca080 12. ? @ 0x00007fbc6213eac3 13. ? @ 0x00007fbc621d0850 2025.07.28 12:02:28.414013 [ 62057 ] {} TCPHandler: Code: 394. DB::Exception: Query was cancelled. (QUERY_WAS_CANCELLED), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000000a074fcb 4. /build/src/Interpreters/ProcessList.cpp:567: DB::QueryStatus::throwQueryWasCancelled() const @ 0x0000000014a4bc85 5. /build/src/Interpreters/ProcessList.cpp:520: DB::QueryStatus::throwProperExceptionIfNeeded(unsigned long const&, unsigned long const&) @ 0x0000000014a4bbd9 6. /build/src/Interpreters/ProcessList.cpp:557: DB::QueryStatus::checkTimeLimit() @ 0x0000000014a4c2cd 7. /build/src/Processors/Executors/PipelineExecutor.cpp:206: DB::PipelineExecutor::finalizeExecution() @ 0x00000000169b13ba 8. /build/src/Processors/Executors/PipelineExecutor.cpp:153: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x00000000169b0584 9. /build/src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:se190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169bfeab 10. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc3d92 11. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fcca080 12. ? @ 0x00007fbc6213eac3 13. ? @ 0x00007fbc621d0850 Job's origin stack trace: 0. /build/src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000000fc33b84 1. /build/src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000000fcc2ea7 2. /build/src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fcc535c 3. /build/src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000000fcc584d 4. /build/src/Common/ThreadPool.h:279: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x00000000169bf193 5. /build/src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x00000000169bf518 6. /build/src/Server/TCPHandler.cpp:1237: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x00000000168f1525 7. /build/src/Server/TCPHandler.cpp:678: DB::TCPHandler::runImpl() @ 0x00000000168e68e5 8. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 9. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 10. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 11. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 12. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 13. ? @ 0x00007fbc6213eac3 14. ? @ 0x00007fbc621d0850 2025.07.28 12:02:28.624484 [ 17255 ] {} TCPHandler: Code: 394. DB::Exception: Query was cancelled. (QUERY_WAS_CANCELLED), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000000a074fcb 4. /build/src/Interpreters/ProcessList.cpp:567: DB::QueryStatus::throwQueryWasCancelled() const @ 0x0000000014a4bc85 5. /build/src/Interpreters/ProcessList.cpp:520: DB::QueryStatus::throwProperExceptionIfNeeded(unsigned long const&, unsigned long const&) @ 0x0000000014a4bbd9 6. /build/src/Interpreters/ProcessList.cpp:557: DB::QueryStatus::checkTimeLimit() @ 0x0000000014a4c2cd 7. /build/src/Processors/Executors/PipelineExecutor.cpp:206: DB::PipelineExecutor::finalizeExecution() @ 0x00000000169b13ba 8. /build/src/Processors/Executors/PipelineExecutor.cpp:181: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x00000000169b1726 9. /build/src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x00000000169c081c 10. /build/src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x00000000169c0978 11. /build/src/Interpreters/InterpreterKillQueryQuery.cpp:442: DB::InterpreterKillQueryQuery::getSelectResult(String const&, String const&) @ 0x0000000014cf0f6b 12. /build/src/Interpreters/InterpreterKillQueryQuery.cpp:222: DB::InterpreterKillQueryQuery::execute() @ 0x0000000014cebde2 13. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88dc9 14. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 15. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 16. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 17. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 18. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 19. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 20. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 21. ? @ 0x00007fbc6213eac3 22. ? @ 0x00007fbc621d0850 2025.07.28 12:02:28.700120 [ 7625 ] {37d09958-38a0-4616-badf-84988b2de6ad} executeQuery: Code: 394. DB::Exception: Query was cancelled. (QUERY_WAS_CANCELLED) (version 25.3.6.10636.altinitytest (altinity build)) (from [::1]:35394) (comment: 02461_cancel_finish_race.sh) (query 1, line 1) (in query: KILL QUERY WHERE current_database = 'test_dtwle8fg' SYNC FORMAT Null), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000000a074fcb 4. /build/src/Interpreters/ProcessList.cpp:567: DB::QueryStatus::throwQueryWasCancelled() const @ 0x0000000014a4bc85 5. /build/src/Interpreters/ProcessList.cpp:520: DB::QueryStatus::throwProperExceptionIfNeeded(unsigned long const&, unsigned long const&) @ 0x0000000014a4bbd9 6. /build/src/Interpreters/ProcessList.cpp:557: DB::QueryStatus::checkTimeLimit() @ 0x0000000014a4c2cd 7. /build/src/Processors/Executors/PipelineExecutor.cpp:206: DB::PipelineExecutor::finalizeExecution() @ 0x00000000169b13ba 8. /build/src/Processors/Executors/PipelineExecutor.cpp:153: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x00000000169b0584 9. /build/src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:se190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169bfeab 10. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc3d92 11. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fcca080 12. ? @ 0x00007fbc6213eac3 13. ? @ 0x00007fbc621d0850 2025.07.28 12:02:28.703086 [ 7625 ] {} TCPHandler: Code: 394. DB::Exception: Query was cancelled. (QUERY_WAS_CANCELLED), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000000a074fcb 4. /build/src/Interpreters/ProcessList.cpp:567: DB::QueryStatus::throwQueryWasCancelled() const @ 0x0000000014a4bc85 5. /build/src/Interpreters/ProcessList.cpp:520: DB::QueryStatus::throwProperExceptionIfNeeded(unsigned long const&, unsigned long const&) @ 0x0000000014a4bbd9 6. /build/src/Interpreters/ProcessList.cpp:557: DB::QueryStatus::checkTimeLimit() @ 0x0000000014a4c2cd 7. /build/src/Processors/Executors/PipelineExecutor.cpp:206: DB::PipelineExecutor::finalizeExecution() @ 0x00000000169b13ba 8. /build/src/Processors/Executors/PipelineExecutor.cpp:153: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x00000000169b0584 9. /build/src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:se190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169bfeab 10. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc3d92 11. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fcca080 12. ? @ 0x00007fbc6213eac3 13. ? @ 0x00007fbc621d0850 Job's origin stack trace: 0. /build/src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000000fc33b84 1. /build/src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000000fcc2ea7 2. /build/src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fcc535c 3. /build/src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000000fcc584d 4. /build/src/Common/ThreadPool.h:279: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x00000000169bf193 5. /build/src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x00000000169bf518 6. /build/src/Server/TCPHandler.cpp:1237: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x00000000168f1525 7. /build/src/Server/TCPHandler.cpp:678: DB::TCPHandler::runImpl() @ 0x00000000168e68e5 8. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 9. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 10. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 11. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 12. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 13. ? @ 0x00007fbc6213eac3 14. ? @ 0x00007fbc621d0850 2025.07.28 12:02:28.813189 [ 62065 ] {} TCPHandler: Code: 394. DB::Exception: Query was cancelled. (QUERY_WAS_CANCELLED), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000000a074fcb 4. /build/src/Interpreters/ProcessList.cpp:567: DB::QueryStatus::throwQueryWasCancelled() const @ 0x0000000014a4bc85 5. /build/src/Interpreters/ProcessList.cpp:520: DB::QueryStatus::throwProperExceptionIfNeeded(unsigned long const&, unsigned long const&) @ 0x0000000014a4bbd9 6. /build/src/Interpreters/ProcessList.cpp:531: DB::QueryStatus::addPipelineExecutor(DB::PipelineExecutor*) @ 0x0000000014a4bd9c 7. /build/src/Processors/Executors/PipelineExecutor.cpp:73: DB::PipelineExecutor::PipelineExecutor(std::shared_ptr, std::allocator>>>&, std::shared_ptr) @ 0x00000000169afe31 8. /build/contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x00000000169c07b5 9. /build/src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x00000000169c0978 10. /build/src/Interpreters/InterpreterKillQueryQuery.cpp:439: DB::InterpreterKillQueryQuery::getSelectResult(String const&, String const&) @ 0x0000000014cf0f04 11. /build/src/Interpreters/InterpreterKillQueryQuery.cpp:222: DB::InterpreterKillQueryQuery::execute() @ 0x0000000014cebde2 12. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88dc9 13. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 14. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 15. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 16. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 17. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 18. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 19. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 20. ? @ 0x00007fbc6213eac3 21. ? @ 0x00007fbc621d0850 2025.07.28 12:02:28.829291 [ 62314 ] {33309e9f-7405-4c43-b860-51f3433174a9} executeQuery: Code: 394. DB::Exception: Query was cancelled. (QUERY_WAS_CANCELLED) (version 25.3.6.10636.altinitytest (altinity build)) (from [::1]:35428) (comment: 02461_cancel_finish_race.sh) (query 1, line 1) (in query: KILL QUERY WHERE current_database = 'test_dtwle8fg' SYNC FORMAT Null), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000000a074fcb 4. /build/src/Interpreters/ProcessList.cpp:567: DB::QueryStatus::throwQueryWasCancelled() const @ 0x0000000014a4bc85 5. /build/src/Interpreters/ProcessList.cpp:520: DB::QueryStatus::throwProperExceptionIfNeeded(unsigned long const&, unsigned long const&) @ 0x0000000014a4bbd9 6. /build/src/Interpreters/ProcessList.cpp:557: DB::QueryStatus::checkTimeLimit() @ 0x0000000014a4c2cd 7. /build/src/Processors/Executors/PipelineExecutor.cpp:206: DB::PipelineExecutor::finalizeExecution() @ 0x00000000169b13ba 8. /build/src/Processors/Executors/PipelineExecutor.cpp:153: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x00000000169b0584 9. /build/src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:se190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169bfeab 10. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc3d92 11. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fcca080 12. ? @ 0x00007fbc6213eac3 13. ? @ 0x00007fbc621d0850 2025.07.28 12:02:28.839994 [ 62314 ] {} TCPHandler: Code: 394. DB::Exception: Query was cancelled. (QUERY_WAS_CANCELLED), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000000a074fcb 4. /build/src/Interpreters/ProcessList.cpp:567: DB::QueryStatus::throwQueryWasCancelled() const @ 0x0000000014a4bc85 5. /build/src/Interpreters/ProcessList.cpp:520: DB::QueryStatus::throwProperExceptionIfNeeded(unsigned long const&, unsigned long const&) @ 0x0000000014a4bbd9 6. /build/src/Interpreters/ProcessList.cpp:557: DB::QueryStatus::checkTimeLimit() @ 0x0000000014a4c2cd 7. /build/src/Processors/Executors/PipelineExecutor.cpp:206: DB::PipelineExecutor::finalizeExecution() @ 0x00000000169b13ba 8. /build/src/Processors/Executors/PipelineExecutor.cpp:153: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x00000000169b0584 9. /build/src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:se190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169bfeab 10. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc3d92 11. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fcca080 12. ? @ 0x00007fbc6213eac3 13. ? @ 0x00007fbc621d0850 Job's origin stack trace: 0. /build/src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000000fc33b84 1. /build/src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000000fcc2ea7 2. /build/src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fcc535c 3. /build/src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000000fcc584d 4. /build/src/Common/ThreadPool.h:279: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x00000000169bf193 5. /build/src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x00000000169bf518 6. /build/src/Server/TCPHandler.cpp:1237: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x00000000168f1525 7. /build/src/Server/TCPHandler.cpp:678: DB::TCPHandler::runImpl() @ 0x00000000168e68e5 8. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 9. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 10. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 11. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 12. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 13. ? @ 0x00007fbc6213eac3 14. ? @ 0x00007fbc621d0850 2025.07.28 12:02:28.852920 [ 17256 ] {911e3546-7a1b-4af5-9469-66955de2a8f7} executeQuery: Code: 394. DB::Exception: Query was cancelled. (QUERY_WAS_CANCELLED) (version 25.3.6.10636.altinitytest (altinity build)) (from [::1]:35472) (comment: 02461_cancel_finish_race.sh) (query 1, line 1) (in query: KILL QUERY WHERE current_database = 'test_dtwle8fg' SYNC FORMAT Null), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000000a074fcb 4. /build/src/Interpreters/ProcessList.cpp:567: DB::QueryStatus::throwQueryWasCancelled() const @ 0x0000000014a4bc85 5. /build/src/Interpreters/ProcessList.cpp:520: DB::QueryStatus::throwProperExceptionIfNeeded(unsigned long const&, unsigned long const&) @ 0x0000000014a4bbd9 6. /build/src/Interpreters/ProcessList.cpp:557: DB::QueryStatus::checkTimeLimit() @ 0x0000000014a4c2cd 7. /build/src/Processors/Executors/PipelineExecutor.cpp:206: DB::PipelineExecutor::finalizeExecution() @ 0x00000000169b13ba 8. /build/src/Processors/Executors/PipelineExecutor.cpp:153: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x00000000169b0584 9. /build/src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:se190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169bfeab 10. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc3d92 11. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fcca080 12. ? @ 0x00007fbc6213eac3 13. ? @ 0x00007fbc621d0850 2025.07.28 12:02:28.856014 [ 17256 ] {} TCPHandler: Code: 394. DB::Exception: Query was cancelled. (QUERY_WAS_CANCELLED), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000000a074fcb 4. /build/src/Interpreters/ProcessList.cpp:567: DB::QueryStatus::throwQueryWasCancelled() const @ 0x0000000014a4bc85 5. /build/src/Interpreters/ProcessList.cpp:520: DB::QueryStatus::throwProperExceptionIfNeeded(unsigned long const&, unsigned long const&) @ 0x0000000014a4bbd9 6. /build/src/Interpreters/ProcessList.cpp:557: DB::QueryStatus::checkTimeLimit() @ 0x0000000014a4c2cd 7. /build/src/Processors/Executors/PipelineExecutor.cpp:206: DB::PipelineExecutor::finalizeExecution() @ 0x00000000169b13ba 8. /build/src/Processors/Executors/PipelineExecutor.cpp:153: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x00000000169b0584 9. /build/src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:se190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169bfeab 10. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc3d92 11. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fcca080 12. ? @ 0x00007fbc6213eac3 13. ? @ 0x00007fbc621d0850 Job's origin stack trace: 0. /build/src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000000fc33b84 1. /build/src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000000fcc2ea7 2. /build/src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fcc535c 3. /build/src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000000fcc584d 4. /build/src/Common/ThreadPool.h:279: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x00000000169bf193 5. /build/src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x00000000169bf518 6. /build/src/Server/TCPHandler.cpp:1237: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x00000000168f1525 7. /build/src/Server/TCPHandler.cpp:678: DB::TCPHandler::runImpl() @ 0x00000000168e68e5 8. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 9. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 10. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 11. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 12. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 13. ? @ 0x00007fbc6213eac3 14. ? @ 0x00007fbc621d0850 2025.07.28 12:02:28.898748 [ 62053 ] {} TCPHandler: Code: 394. DB::Exception: Query was cancelled. (QUERY_WAS_CANCELLED), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000000a074fcb 4. /build/src/Interpreters/ProcessList.cpp:567: DB::QueryStatus::throwQueryWasCancelled() const @ 0x0000000014a4bc85 5. /build/src/Interpreters/ProcessList.cpp:520: DB::QueryStatus::throwProperExceptionIfNeeded(unsigned long const&, unsigned long const&) @ 0x0000000014a4bbd9 6. /build/src/Interpreters/ProcessList.cpp:557: DB::QueryStatus::checkTimeLimit() @ 0x0000000014a4c2cd 7. /build/src/Processors/Executors/PipelineExecutor.cpp:206: DB::PipelineExecutor::finalizeExecution() @ 0x00000000169b13ba 8. /build/src/Processors/Executors/PipelineExecutor.cpp:181: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x00000000169b1726 9. /build/src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x00000000169c081c 10. /build/src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x00000000169c0978 11. /build/src/Interpreters/InterpreterKillQueryQuery.cpp:439: DB::InterpreterKillQueryQuery::getSelectResult(String const&, String const&) @ 0x0000000014cf0f04 12. /build/src/Interpreters/InterpreterKillQueryQuery.cpp:222: DB::InterpreterKillQueryQuery::execute() @ 0x0000000014cebde2 13. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88dc9 14. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 15. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 16. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 17. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 18. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 19. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 20. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 21. ? @ 0x00007fbc6213eac3 22. ? @ 0x00007fbc621d0850 2025.07.28 12:02:28.933664 [ 62057 ] {} TCPHandler: Code: 394. DB::Exception: Query was cancelled. (QUERY_WAS_CANCELLED), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000000a074fcb 4. /build/src/Interpreters/ProcessList.cpp:567: DB::QueryStatus::throwQueryWasCancelled() const @ 0x0000000014a4bc85 5. /build/src/Interpreters/ProcessList.cpp:520: DB::QueryStatus::throwProperExceptionIfNeeded(unsigned long const&, unsigned long const&) @ 0x0000000014a4bbd9 6. /build/src/Interpreters/ProcessList.cpp:557: DB::QueryStatus::checkTimeLimit() @ 0x0000000014a4c2cd 7. /build/src/Processors/Executors/PipelineExecutor.cpp:206: DB::PipelineExecutor::finalizeExecution() @ 0x00000000169b13ba 8. /build/src/Processors/Executors/PipelineExecutor.cpp:181: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x00000000169b1726 9. /build/src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x00000000169c081c 10. /build/src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x00000000169c0978 11. /build/src/Interpreters/InterpreterKillQueryQuery.cpp:442: DB::InterpreterKillQueryQuery::getSelectResult(String const&, String const&) @ 0x0000000014cf0f6b 12. /build/src/Interpreters/InterpreterKillQueryQuery.cpp:222: DB::InterpreterKillQueryQuery::execute() @ 0x0000000014cebde2 13. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88dc9 14. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 15. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 16. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 17. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 18. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 19. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 20. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 21. ? @ 0x00007fbc6213eac3 22. ? @ 0x00007fbc621d0850 2025.07.28 12:02:28.990470 [ 5951 ] {8c2af695-a094-4617-b13b-de6c350a0238} executeQuery: Code: 394. DB::Exception: Query was cancelled. (QUERY_WAS_CANCELLED) (version 25.3.6.10636.altinitytest (altinity build)) (from [::1]:35524) (comment: 02461_cancel_finish_race.sh) (query 1, line 1) (in query: KILL QUERY WHERE current_database = 'test_dtwle8fg' SYNC FORMAT Null), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000000a074fcb 4. /build/src/Interpreters/ProcessList.cpp:567: DB::QueryStatus::throwQueryWasCancelled() const @ 0x0000000014a4bc85 5. /build/src/Interpreters/ProcessList.cpp:520: DB::QueryStatus::throwProperExceptionIfNeeded(unsigned long const&, unsigned long const&) @ 0x0000000014a4bbd9 6. /build/src/Interpreters/ProcessList.cpp:557: DB::QueryStatus::checkTimeLimit() @ 0x0000000014a4c2cd 7. /build/src/Processors/Executors/PipelineExecutor.cpp:206: DB::PipelineExecutor::finalizeExecution() @ 0x00000000169b13ba 8. /build/src/Processors/Executors/PipelineExecutor.cpp:153: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x00000000169b0584 9. /build/src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:se190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169bfeab 10. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc3d92 11. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fcca080 12. ? @ 0x00007fbc6213eac3 13. ? @ 0x00007fbc621d0850 2025.07.28 12:02:29.018590 [ 5951 ] {} TCPHandler: Code: 394. DB::Exception: Query was cancelled. (QUERY_WAS_CANCELLED), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000000a074fcb 4. /build/src/Interpreters/ProcessList.cpp:567: DB::QueryStatus::throwQueryWasCancelled() const @ 0x0000000014a4bc85 5. /build/src/Interpreters/ProcessList.cpp:520: DB::QueryStatus::throwProperExceptionIfNeeded(unsigned long const&, unsigned long const&) @ 0x0000000014a4bbd9 6. /build/src/Interpreters/ProcessList.cpp:557: DB::QueryStatus::checkTimeLimit() @ 0x0000000014a4c2cd 7. /build/src/Processors/Executors/PipelineExecutor.cpp:206: DB::PipelineExecutor::finalizeExecution() @ 0x00000000169b13ba 8. /build/src/Processors/Executors/PipelineExecutor.cpp:153: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x00000000169b0584 9. /build/src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:se190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169bfeab 10. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc3d92 11. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fcca080 12. ? @ 0x00007fbc6213eac3 13. ? @ 0x00007fbc621d0850 Job's origin stack trace: 0. /build/src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000000fc33b84 1. /build/src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000000fcc2ea7 2. /build/src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fcc535c 3. /build/src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000000fcc584d 4. /build/src/Common/ThreadPool.h:279: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x00000000169bf193 5. /build/src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x00000000169bf518 6. /build/src/Server/TCPHandler.cpp:1237: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x00000000168f1525 7. /build/src/Server/TCPHandler.cpp:678: DB::TCPHandler::runImpl() @ 0x00000000168e68e5 8. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 9. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 10. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 11. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 12. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 13. ? @ 0x00007fbc6213eac3 14. ? @ 0x00007fbc621d0850 2025.07.28 12:02:29.063285 [ 3961 ] {} test_13.rmt2 (7f9b740d-015c-470e-8cc6-8ba33be0dc63): auto DB::StorageReplicatedMergeTree::processQueueEntry(ReplicatedMergeTreeQueue::SelectedEntryPtr)::(anonymous class)::operator()(LogEntryPtr &) const: Code: 86. DB::HTTPException: Received error from remote server http://146b4357c08d:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Ftest%2F01165%2Ftest_13%2Frmt%2Freplicas%2F1&part=20250728_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.6.10636.altinitytest (altinity build)) '. (RECEIVED_ERROR_FROM_REMOTE_IO_SERVER), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.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 const&, int&&, String const&, unsigned long&&, String const&) @ 0x000000000feda8d9 4. /build/src/IO/HTTPCommon.cpp:104: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x000000000feda6e2 5. /build/src/IO/HTTPCommon.cpp:93: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x000000000feda537 6. /build/src/IO/ReadWriteBufferFromHTTP.cpp:277: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x000000001184a4c4 7. /build/src/IO/ReadWriteBufferFromHTTP.cpp:285: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x000000001184a615 8. /build/src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x000000001184ae59 9. /build/src/IO/ReadWriteBufferFromHTTP.cpp:472: void std::__function::__policy_invoker::__call_impl[abi:se190107]>(std::__function::__policy_storage const*) @ 0x000000001184cedd 10. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001184858b 11. /build/src/IO/ReadWriteBufferFromHTTP.cpp:465: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x000000001184bf0b 12. /build/src/IO/ReadBuffer.h:60: DB::ReadBuffer::next() @ 0x000000000a148c7b 13. /build/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) @ 0x0000000011849fb2 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]>&)>&, 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&) @ 0x0000000011841980 15. /build/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) @ 0x000000001621208e 16. /build/src/Storages/StorageReplicatedMergeTree.cpp:5228: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl[abi:se190107] const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000015f9a5fe 17. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000015ed8bfd 18. /build/src/Storages/StorageReplicatedMergeTree.cpp:2514: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x0000000015ec9aab 19. /build/src/Storages/StorageReplicatedMergeTree.cpp:2349: DB::StorageReplicatedMergeTree::executeLogEntry(DB::ReplicatedMergeTreeLogEntry&) @ 0x0000000015eba91b 20. /build/src/Storages/StorageReplicatedMergeTree.cpp:3876: bool std::__function::__policy_invoker&)>::__call_impl[abi:se190107])::$_1, bool (std::shared_ptr&)>>(std::__function::__policy_storage const*, std::shared_ptr&) @ 0x0000000015f9837e 21. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000165d6fc3 22. /build/src/Storages/StorageReplicatedMergeTree.cpp:3872: DB::StorageReplicatedMergeTree::processQueueEntry(std::shared_ptr) @ 0x0000000015efc18a 23. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001624c1b2 24. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000162f9c70 25. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x00000000162fa55a 26. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc6653 27. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000000fccc4c3 28. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc3d92 29. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fcca080 30. ? @ 0x00007fbc6213eac3 31. ? @ 0x00007fbc621d0850 (version 25.3.6.10636.altinitytest (altinity build)) 2025.07.28 12:02:29.085298 [ 5112 ] {} TCPHandler: Code: 394. DB::Exception: Query was cancelled. (QUERY_WAS_CANCELLED), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000000a074fcb 4. /build/src/Interpreters/ProcessList.cpp:567: DB::QueryStatus::throwQueryWasCancelled() const @ 0x0000000014a4bc85 5. /build/src/Interpreters/ProcessList.cpp:520: DB::QueryStatus::throwProperExceptionIfNeeded(unsigned long const&, unsigned long const&) @ 0x0000000014a4bbd9 6. /build/src/Interpreters/ProcessList.cpp:557: DB::QueryStatus::checkTimeLimit() @ 0x0000000014a4c2cd 7. /build/src/Processors/Executors/PipelineExecutor.cpp:206: DB::PipelineExecutor::finalizeExecution() @ 0x00000000169b13ba 8. /build/src/Processors/Executors/PipelineExecutor.cpp:181: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x00000000169b1726 9. /build/src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x00000000169c081c 10. /build/src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x00000000169c0978 11. /build/src/Interpreters/InterpreterKillQueryQuery.cpp:439: DB::InterpreterKillQueryQuery::getSelectResult(String const&, String const&) @ 0x0000000014cf0f04 12. /build/src/Interpreters/InterpreterKillQueryQuery.cpp:222: DB::InterpreterKillQueryQuery::execute() @ 0x0000000014cebde2 13. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88dc9 14. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 15. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 16. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 17. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 18. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 19. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 20. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 21. ? @ 0x00007fbc6213eac3 22. ? @ 0x00007fbc621d0850 2025.07.28 12:02:29.132132 [ 62325 ] {6432008b-d3dc-4b49-95d6-941d466d61bb} executeQuery: Code: 394. DB::Exception: Query was cancelled. (QUERY_WAS_CANCELLED) (version 25.3.6.10636.altinitytest (altinity build)) (from [::1]:35576) (comment: 02461_cancel_finish_race.sh) (query 1, line 1) (in query: KILL QUERY WHERE current_database = 'test_dtwle8fg' SYNC FORMAT Null), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000000a074fcb 4. /build/src/Interpreters/ProcessList.cpp:567: DB::QueryStatus::throwQueryWasCancelled() const @ 0x0000000014a4bc85 5. /build/src/Interpreters/ProcessList.cpp:520: DB::QueryStatus::throwProperExceptionIfNeeded(unsigned long const&, unsigned long const&) @ 0x0000000014a4bbd9 6. /build/src/Interpreters/ProcessList.cpp:557: DB::QueryStatus::checkTimeLimit() @ 0x0000000014a4c2cd 7. /build/src/Processors/Executors/PipelineExecutor.cpp:206: DB::PipelineExecutor::finalizeExecution() @ 0x00000000169b13ba 8. /build/src/Processors/Executors/PipelineExecutor.cpp:153: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x00000000169b0584 9. /build/src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:se190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169bfeab 10. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc3d92 11. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fcca080 12. ? @ 0x00007fbc6213eac3 13. ? @ 0x00007fbc621d0850 2025.07.28 12:02:29.157871 [ 62325 ] {} TCPHandler: Code: 394. DB::Exception: Query was cancelled. (QUERY_WAS_CANCELLED), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000000a074fcb 4. /build/src/Interpreters/ProcessList.cpp:567: DB::QueryStatus::throwQueryWasCancelled() const @ 0x0000000014a4bc85 5. /build/src/Interpreters/ProcessList.cpp:520: DB::QueryStatus::throwProperExceptionIfNeeded(unsigned long const&, unsigned long const&) @ 0x0000000014a4bbd9 6. /build/src/Interpreters/ProcessList.cpp:557: DB::QueryStatus::checkTimeLimit() @ 0x0000000014a4c2cd 7. /build/src/Processors/Executors/PipelineExecutor.cpp:206: DB::PipelineExecutor::finalizeExecution() @ 0x00000000169b13ba 8. /build/src/Processors/Executors/PipelineExecutor.cpp:153: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x00000000169b0584 9. /build/src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:se190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169bfeab 10. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc3d92 11. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fcca080 12. ? @ 0x00007fbc6213eac3 13. ? @ 0x00007fbc621d0850 Job's origin stack trace: 0. /build/src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000000fc33b84 1. /build/src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000000fcc2ea7 2. /build/src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fcc535c 3. /build/src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000000fcc584d 4. /build/src/Common/ThreadPool.h:279: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x00000000169bf193 5. /build/src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x00000000169bf518 6. /build/src/Server/TCPHandler.cpp:1237: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x00000000168f1525 7. /build/src/Server/TCPHandler.cpp:678: DB::TCPHandler::runImpl() @ 0x00000000168e68e5 8. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 9. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 10. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 11. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 12. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 13. ? @ 0x00007fbc6213eac3 14. ? @ 0x00007fbc621d0850 2025.07.28 12:02:29.543698 [ 62058 ] {} TCPHandler: Code: 394. DB::Exception: Query was cancelled. (QUERY_WAS_CANCELLED), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000000a074fcb 4. /build/src/Interpreters/ProcessList.cpp:567: DB::QueryStatus::throwQueryWasCancelled() const @ 0x0000000014a4bc85 5. /build/src/Interpreters/ProcessList.cpp:520: DB::QueryStatus::throwProperExceptionIfNeeded(unsigned long const&, unsigned long const&) @ 0x0000000014a4bbd9 6. /build/src/Interpreters/ProcessList.cpp:557: DB::QueryStatus::checkTimeLimit() @ 0x0000000014a4c2cd 7. /build/src/Processors/Executors/PipelineExecutor.cpp:206: DB::PipelineExecutor::finalizeExecution() @ 0x00000000169b13ba 8. /build/src/Processors/Executors/PipelineExecutor.cpp:181: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x00000000169b1726 9. /build/src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x00000000169c081c 10. /build/src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x00000000169c0978 11. /build/src/Interpreters/InterpreterKillQueryQuery.cpp:439: DB::InterpreterKillQueryQuery::getSelectResult(String const&, String const&) @ 0x0000000014cf0f04 12. /build/src/Interpreters/InterpreterKillQueryQuery.cpp:222: DB::InterpreterKillQueryQuery::execute() @ 0x0000000014cebde2 13. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88dc9 14. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 15. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 16. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 17. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 18. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 19. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 20. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 21. ? @ 0x00007fbc6213eac3 22. ? @ 0x00007fbc621d0850 2025.07.28 12:02:29.552620 [ 62314 ] {ca9d9df5-1c1f-4bfa-907e-977dd942ce2c} executeQuery: Code: 394. DB::Exception: Query was cancelled. (QUERY_WAS_CANCELLED) (version 25.3.6.10636.altinitytest (altinity build)) (from [::1]:35684) (comment: 02461_cancel_finish_race.sh) (query 1, line 1) (in query: KILL QUERY WHERE current_database = 'test_dtwle8fg' SYNC FORMAT Null), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000000a074fcb 4. /build/src/Interpreters/ProcessList.cpp:567: DB::QueryStatus::throwQueryWasCancelled() const @ 0x0000000014a4bc85 5. /build/src/Interpreters/ProcessList.cpp:520: DB::QueryStatus::throwProperExceptionIfNeeded(unsigned long const&, unsigned long const&) @ 0x0000000014a4bbd9 6. /build/src/Interpreters/ProcessList.cpp:557: DB::QueryStatus::checkTimeLimit() @ 0x0000000014a4c2cd 7. /build/src/Processors/Executors/PipelineExecutor.cpp:206: DB::PipelineExecutor::finalizeExecution() @ 0x00000000169b13ba 8. /build/src/Processors/Executors/PipelineExecutor.cpp:153: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x00000000169b0584 9. /build/src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:se190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169bfeab 10. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc3d92 11. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fcca080 12. ? @ 0x00007fbc6213eac3 13. ? @ 0x00007fbc621d0850 2025.07.28 12:02:29.561121 [ 17255 ] {6831e56b-5f0b-4cb6-98d7-6fab93594954} executeQuery: Code: 394. DB::Exception: Query was cancelled. (QUERY_WAS_CANCELLED) (version 25.3.6.10636.altinitytest (altinity build)) (from [::1]:35680) (comment: 02461_cancel_finish_race.sh) (query 1, line 1) (in query: KILL QUERY WHERE current_database = 'test_dtwle8fg' SYNC FORMAT Null), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000000a074fcb 4. /build/src/Interpreters/ProcessList.cpp:567: DB::QueryStatus::throwQueryWasCancelled() const @ 0x0000000014a4bc85 5. /build/src/Interpreters/ProcessList.cpp:520: DB::QueryStatus::throwProperExceptionIfNeeded(unsigned long const&, unsigned long const&) @ 0x0000000014a4bbd9 6. /build/src/Interpreters/ProcessList.cpp:557: DB::QueryStatus::checkTimeLimit() @ 0x0000000014a4c2cd 7. /build/src/Processors/Executors/PipelineExecutor.cpp:206: DB::PipelineExecutor::finalizeExecution() @ 0x00000000169b13ba 8. /build/src/Processors/Executors/PipelineExecutor.cpp:153: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x00000000169b0584 9. /build/src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:se190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169bfeab 10. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc3d92 11. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fcca080 12. ? @ 0x00007fbc6213eac3 13. ? @ 0x00007fbc621d0850 2025.07.28 12:02:29.592397 [ 17255 ] {} TCPHandler: Code: 394. DB::Exception: Query was cancelled. (QUERY_WAS_CANCELLED), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000000a074fcb 4. /build/src/Interpreters/ProcessList.cpp:567: DB::QueryStatus::throwQueryWasCancelled() const @ 0x0000000014a4bc85 5. /build/src/Interpreters/ProcessList.cpp:520: DB::QueryStatus::throwProperExceptionIfNeeded(unsigned long const&, unsigned long const&) @ 0x0000000014a4bbd9 6. /build/src/Interpreters/ProcessList.cpp:557: DB::QueryStatus::checkTimeLimit() @ 0x0000000014a4c2cd 7. /build/src/Processors/Executors/PipelineExecutor.cpp:206: DB::PipelineExecutor::finalizeExecution() @ 0x00000000169b13ba 8. /build/src/Processors/Executors/PipelineExecutor.cpp:153: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x00000000169b0584 9. /build/src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:se190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169bfeab 10. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc3d92 11. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fcca080 12. ? @ 0x00007fbc6213eac3 13. ? @ 0x00007fbc621d0850 Job's origin stack trace: 0. /build/src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000000fc33b84 1. /build/src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000000fcc2ea7 2. /build/src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fcc535c 3. /build/src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000000fcc584d 4. /build/src/Common/ThreadPool.h:279: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x00000000169bf193 5. /build/src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x00000000169bf518 6. /build/src/Server/TCPHandler.cpp:1237: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x00000000168f1525 7. /build/src/Server/TCPHandler.cpp:678: DB::TCPHandler::runImpl() @ 0x00000000168e68e5 8. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 9. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 10. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 11. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 12. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 13. ? @ 0x00007fbc6213eac3 14. ? @ 0x00007fbc621d0850 2025.07.28 12:02:29.603542 [ 62056 ] {} TCPHandler: Code: 394. DB::Exception: Query was cancelled. (QUERY_WAS_CANCELLED), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000000a074fcb 4. /build/src/Interpreters/ProcessList.cpp:567: DB::QueryStatus::throwQueryWasCancelled() const @ 0x0000000014a4bc85 5. /build/src/Interpreters/ProcessList.cpp:520: DB::QueryStatus::throwProperExceptionIfNeeded(unsigned long const&, unsigned long const&) @ 0x0000000014a4bbd9 6. /build/src/Interpreters/ProcessList.cpp:531: DB::QueryStatus::addPipelineExecutor(DB::PipelineExecutor*) @ 0x0000000014a4bd9c 7. /build/src/Processors/Executors/PipelineExecutor.cpp:73: DB::PipelineExecutor::PipelineExecutor(std::shared_ptr, std::allocator>>>&, std::shared_ptr) @ 0x00000000169afe31 8. /build/contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x00000000169c07b5 9. /build/src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x00000000169c0978 10. /build/src/Interpreters/InterpreterKillQueryQuery.cpp:439: DB::InterpreterKillQueryQuery::getSelectResult(String const&, String const&) @ 0x0000000014cf0f04 11. /build/src/Interpreters/InterpreterKillQueryQuery.cpp:222: DB::InterpreterKillQueryQuery::execute() @ 0x0000000014cebde2 12. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88dc9 13. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 14. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 15. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 16. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 17. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 18. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 19. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 20. ? @ 0x00007fbc6213eac3 21. ? @ 0x00007fbc621d0850 2025.07.28 12:02:29.605409 [ 5879 ] {90beea79-2675-4591-baaa-34d76395f753} executeQuery: Code: 394. DB::Exception: Query was cancelled. (QUERY_WAS_CANCELLED) (version 25.3.6.10636.altinitytest (altinity build)) (from [::1]:35716) (comment: 02461_cancel_finish_race.sh) (query 1, line 1) (in query: KILL QUERY WHERE current_database = 'test_dtwle8fg' SYNC FORMAT Null), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000000a074fcb 4. /build/src/Interpreters/ProcessList.cpp:567: DB::QueryStatus::throwQueryWasCancelled() const @ 0x0000000014a4bc85 5. /build/src/Interpreters/ProcessList.cpp:520: DB::QueryStatus::throwProperExceptionIfNeeded(unsigned long const&, unsigned long const&) @ 0x0000000014a4bbd9 6. /build/src/Interpreters/ProcessList.cpp:557: DB::QueryStatus::checkTimeLimit() @ 0x0000000014a4c2cd 7. /build/src/Processors/Executors/PipelineExecutor.cpp:206: DB::PipelineExecutor::finalizeExecution() @ 0x00000000169b13ba 8. /build/src/Processors/Executors/PipelineExecutor.cpp:153: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x00000000169b0584 9. /build/src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:se190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169bfeab 10. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc3d92 11. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fcca080 12. ? @ 0x00007fbc6213eac3 13. ? @ 0x00007fbc621d0850 2025.07.28 12:02:29.615760 [ 5879 ] {} TCPHandler: Code: 394. DB::Exception: Query was cancelled. (QUERY_WAS_CANCELLED), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000000a074fcb 4. /build/src/Interpreters/ProcessList.cpp:567: DB::QueryStatus::throwQueryWasCancelled() const @ 0x0000000014a4bc85 5. /build/src/Interpreters/ProcessList.cpp:520: DB::QueryStatus::throwProperExceptionIfNeeded(unsigned long const&, unsigned long const&) @ 0x0000000014a4bbd9 6. /build/src/Interpreters/ProcessList.cpp:557: DB::QueryStatus::checkTimeLimit() @ 0x0000000014a4c2cd 7. /build/src/Processors/Executors/PipelineExecutor.cpp:206: DB::PipelineExecutor::finalizeExecution() @ 0x00000000169b13ba 8. /build/src/Processors/Executors/PipelineExecutor.cpp:153: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x00000000169b0584 9. /build/src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:se190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169bfeab 10. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc3d92 11. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fcca080 12. ? @ 0x00007fbc6213eac3 13. ? @ 0x00007fbc621d0850 Job's origin stack trace: 0. /build/src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000000fc33b84 1. /build/src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000000fcc2ea7 2. /build/src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fcc535c 3. /build/src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000000fcc584d 4. /build/src/Common/ThreadPool.h:279: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x00000000169bf193 5. /build/src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x00000000169bf518 6. /build/src/Server/TCPHandler.cpp:1237: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x00000000168f1525 7. /build/src/Server/TCPHandler.cpp:678: DB::TCPHandler::runImpl() @ 0x00000000168e68e5 8. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 9. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 10. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 11. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 12. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 13. ? @ 0x00007fbc6213eac3 14. ? @ 0x00007fbc621d0850 2025.07.28 12:02:29.629570 [ 62314 ] {} TCPHandler: Code: 394. DB::Exception: Query was cancelled. (QUERY_WAS_CANCELLED), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000000a074fcb 4. /build/src/Interpreters/ProcessList.cpp:567: DB::QueryStatus::throwQueryWasCancelled() const @ 0x0000000014a4bc85 5. /build/src/Interpreters/ProcessList.cpp:520: DB::QueryStatus::throwProperExceptionIfNeeded(unsigned long const&, unsigned long const&) @ 0x0000000014a4bbd9 6. /build/src/Interpreters/ProcessList.cpp:557: DB::QueryStatus::checkTimeLimit() @ 0x0000000014a4c2cd 7. /build/src/Processors/Executors/PipelineExecutor.cpp:206: DB::PipelineExecutor::finalizeExecution() @ 0x00000000169b13ba 8. /build/src/Processors/Executors/PipelineExecutor.cpp:153: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x00000000169b0584 9. /build/src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:se190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169bfeab 10. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc3d92 11. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fcca080 12. ? @ 0x00007fbc6213eac3 13. ? @ 0x00007fbc621d0850 Job's origin stack trace: 0. /build/src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000000fc33b84 1. /build/src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000000fcc2ea7 2. /build/src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fcc535c 3. /build/src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000000fcc584d 4. /build/src/Common/ThreadPool.h:279: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x00000000169bf193 5. /build/src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x00000000169bf518 6. /build/src/Server/TCPHandler.cpp:1237: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x00000000168f1525 7. /build/src/Server/TCPHandler.cpp:678: DB::TCPHandler::runImpl() @ 0x00000000168e68e5 8. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 9. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 10. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 11. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 12. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 13. ? @ 0x00007fbc6213eac3 14. ? @ 0x00007fbc621d0850 2025.07.28 12:02:29.715571 [ 17243 ] {} TCPHandler: Code: 394. DB::Exception: Query was cancelled. (QUERY_WAS_CANCELLED), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000000a074fcb 4. /build/src/Interpreters/ProcessList.cpp:567: DB::QueryStatus::throwQueryWasCancelled() const @ 0x0000000014a4bc85 5. /build/src/Interpreters/ProcessList.cpp:520: DB::QueryStatus::throwProperExceptionIfNeeded(unsigned long const&, unsigned long const&) @ 0x0000000014a4bbd9 6. /build/src/Interpreters/ProcessList.cpp:557: DB::QueryStatus::checkTimeLimit() @ 0x0000000014a4c2cd 7. /build/src/Processors/Executors/PipelineExecutor.cpp:206: DB::PipelineExecutor::finalizeExecution() @ 0x00000000169b13ba 8. /build/src/Processors/Executors/PipelineExecutor.cpp:181: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x00000000169b1726 9. /build/src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x00000000169c081c 10. /build/src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x00000000169c0978 11. /build/src/Interpreters/InterpreterKillQueryQuery.cpp:439: DB::InterpreterKillQueryQuery::getSelectResult(String const&, String const&) @ 0x0000000014cf0f04 12. /build/src/Interpreters/InterpreterKillQueryQuery.cpp:222: DB::InterpreterKillQueryQuery::execute() @ 0x0000000014cebde2 13. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88dc9 14. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 15. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 16. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 17. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 18. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 19. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 20. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 21. ? @ 0x00007fbc6213eac3 22. ? @ 0x00007fbc621d0850 2025.07.28 12:02:29.907833 [ 3974 ] {} test_13.rmt2 (7f9b740d-015c-470e-8cc6-8ba33be0dc63): auto DB::StorageReplicatedMergeTree::processQueueEntry(ReplicatedMergeTreeQueue::SelectedEntryPtr)::(anonymous class)::operator()(LogEntryPtr &) const: Code: 86. DB::HTTPException: Received error from remote server http://146b4357c08d:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Ftest%2F01165%2Ftest_13%2Frmt%2Freplicas%2F1&part=20250728_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.6.10636.altinitytest (altinity build)) '. (RECEIVED_ERROR_FROM_REMOTE_IO_SERVER), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.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 const&, int&&, String const&, unsigned long&&, String const&) @ 0x000000000feda8d9 4. /build/src/IO/HTTPCommon.cpp:104: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x000000000feda6e2 5. /build/src/IO/HTTPCommon.cpp:93: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x000000000feda537 6. /build/src/IO/ReadWriteBufferFromHTTP.cpp:277: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x000000001184a4c4 7. /build/src/IO/ReadWriteBufferFromHTTP.cpp:285: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x000000001184a615 8. /build/src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x000000001184ae59 9. /build/src/IO/ReadWriteBufferFromHTTP.cpp:472: void std::__function::__policy_invoker::__call_impl[abi:se190107]>(std::__function::__policy_storage const*) @ 0x000000001184cedd 10. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001184858b 11. /build/src/IO/ReadWriteBufferFromHTTP.cpp:465: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x000000001184bf0b 12. /build/src/IO/ReadBuffer.h:60: DB::ReadBuffer::next() @ 0x000000000a148c7b 13. /build/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) @ 0x0000000011849fb2 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]>&)>&, 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&) @ 0x0000000011841980 15. /build/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) @ 0x000000001621208e 16. /build/src/Storages/StorageReplicatedMergeTree.cpp:5228: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl[abi:se190107] const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000015f9a5fe 17. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000015ed8bfd 18. /build/src/Storages/StorageReplicatedMergeTree.cpp:2514: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x0000000015ec9aab 19. /build/src/Storages/StorageReplicatedMergeTree.cpp:2349: DB::StorageReplicatedMergeTree::executeLogEntry(DB::ReplicatedMergeTreeLogEntry&) @ 0x0000000015eba91b 20. /build/src/Storages/StorageReplicatedMergeTree.cpp:3876: bool std::__function::__policy_invoker&)>::__call_impl[abi:se190107])::$_1, bool (std::shared_ptr&)>>(std::__function::__policy_storage const*, std::shared_ptr&) @ 0x0000000015f9837e 21. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000165d6fc3 22. /build/src/Storages/StorageReplicatedMergeTree.cpp:3872: DB::StorageReplicatedMergeTree::processQueueEntry(std::shared_ptr) @ 0x0000000015efc18a 23. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001624c1b2 24. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000162f9c70 25. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x00000000162fa55a 26. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc6653 27. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000000fccc4c3 28. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc3d92 29. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fcca080 30. ? @ 0x00007fbc6213eac3 31. ? @ 0x00007fbc621d0850 (version 25.3.6.10636.altinitytest (altinity build)) 2025.07.28 12:02:29.946394 [ 17256 ] {} TCPHandler: Code: 394. DB::Exception: Query 'e8c68cbe-8c68-4f22-819e-81c4f7e907e3' is killed in pending state. (QUERY_WAS_CANCELLED), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x000000000a06b56b 4. /build/src/Interpreters/executeQuery.cpp:1522: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c8a4ef 5. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 6. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 7. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 8. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 9. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 10. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 11. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 12. ? @ 0x00007fbc6213eac3 13. ? @ 0x00007fbc621d0850 2025.07.28 12:02:29.962383 [ 62103 ] {} TCPHandler: Code: 394. DB::Exception: Query was cancelled. (QUERY_WAS_CANCELLED), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000000a074fcb 4. /build/src/Interpreters/ProcessList.cpp:567: DB::QueryStatus::throwQueryWasCancelled() const @ 0x0000000014a4bc85 5. /build/src/Interpreters/ProcessList.cpp:520: DB::QueryStatus::throwProperExceptionIfNeeded(unsigned long const&, unsigned long const&) @ 0x0000000014a4bbd9 6. /build/src/Interpreters/ProcessList.cpp:557: DB::QueryStatus::checkTimeLimit() @ 0x0000000014a4c2cd 7. /build/src/Processors/Executors/PipelineExecutor.cpp:206: DB::PipelineExecutor::finalizeExecution() @ 0x00000000169b13ba 8. /build/src/Processors/Executors/PipelineExecutor.cpp:181: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x00000000169b1726 9. /build/src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x00000000169c081c 10. /build/src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x00000000169c0978 11. /build/src/Interpreters/InterpreterKillQueryQuery.cpp:442: DB::InterpreterKillQueryQuery::getSelectResult(String const&, String const&) @ 0x0000000014cf0f6b 12. /build/src/Interpreters/InterpreterKillQueryQuery.cpp:222: DB::InterpreterKillQueryQuery::execute() @ 0x0000000014cebde2 13. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88dc9 14. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 15. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 16. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 17. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 18. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 19. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 20. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 21. ? @ 0x00007fbc6213eac3 22. ? @ 0x00007fbc621d0850 2025.07.28 12:02:30.153297 [ 17611 ] {68d11de7-67db-4e99-99ad-db70fcc83d83} executeQuery: Code: 394. DB::Exception: Query was cancelled. (QUERY_WAS_CANCELLED) (version 25.3.6.10636.altinitytest (altinity build)) (from [::1]:35970) (comment: 02461_cancel_finish_race.sh) (query 1, line 1) (in query: KILL QUERY WHERE current_database = 'test_dtwle8fg' SYNC FORMAT Null), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000000a074fcb 4. /build/src/Interpreters/ProcessList.cpp:567: DB::QueryStatus::throwQueryWasCancelled() const @ 0x0000000014a4bc85 5. /build/src/Interpreters/ProcessList.cpp:520: DB::QueryStatus::throwProperExceptionIfNeeded(unsigned long const&, unsigned long const&) @ 0x0000000014a4bbd9 6. /build/src/Interpreters/ProcessList.cpp:531: DB::QueryStatus::addPipelineExecutor(DB::PipelineExecutor*) @ 0x0000000014a4bd9c 7. /build/src/Processors/Executors/PipelineExecutor.cpp:73: DB::PipelineExecutor::PipelineExecutor(std::shared_ptr, std::allocator>>>&, std::shared_ptr) @ 0x00000000169afe31 8. /build/contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x00000000169bef66 9. /build/src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x00000000169bf518 10. /build/src/Server/TCPHandler.cpp:1237: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x00000000168f1525 11. /build/src/Server/TCPHandler.cpp:678: DB::TCPHandler::runImpl() @ 0x00000000168e68e5 12. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 13. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 14. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 16. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 17. ? @ 0x00007fbc6213eac3 18. ? @ 0x00007fbc621d0850 2025.07.28 12:02:30.183814 [ 17611 ] {} TCPHandler: Code: 394. DB::Exception: Query was cancelled. (QUERY_WAS_CANCELLED), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000000a074fcb 4. /build/src/Interpreters/ProcessList.cpp:567: DB::QueryStatus::throwQueryWasCancelled() const @ 0x0000000014a4bc85 5. /build/src/Interpreters/ProcessList.cpp:520: DB::QueryStatus::throwProperExceptionIfNeeded(unsigned long const&, unsigned long const&) @ 0x0000000014a4bbd9 6. /build/src/Interpreters/ProcessList.cpp:531: DB::QueryStatus::addPipelineExecutor(DB::PipelineExecutor*) @ 0x0000000014a4bd9c 7. /build/src/Processors/Executors/PipelineExecutor.cpp:73: DB::PipelineExecutor::PipelineExecutor(std::shared_ptr, std::allocator>>>&, std::shared_ptr) @ 0x00000000169afe31 8. /build/contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x00000000169bef66 9. /build/src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x00000000169bf518 10. /build/src/Server/TCPHandler.cpp:1237: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x00000000168f1525 11. /build/src/Server/TCPHandler.cpp:678: DB::TCPHandler::runImpl() @ 0x00000000168e68e5 12. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 13. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 14. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 16. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 17. ? @ 0x00007fbc6213eac3 18. ? @ 0x00007fbc621d0850 2025.07.28 12:02:30.190234 [ 4963 ] {89732f16-81bb-438e-8171-68d2b1b0015a} executeQuery: Code: 394. DB::Exception: Query was cancelled. (QUERY_WAS_CANCELLED) (version 25.3.6.10636.altinitytest (altinity build)) (from [::1]:35940) (comment: 02461_cancel_finish_race.sh) (query 1, line 1) (in query: KILL QUERY WHERE current_database = 'test_dtwle8fg' SYNC FORMAT Null), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000000a074fcb 4. /build/src/Interpreters/ProcessList.cpp:567: DB::QueryStatus::throwQueryWasCancelled() const @ 0x0000000014a4bc85 5. /build/src/Interpreters/ProcessList.cpp:520: DB::QueryStatus::throwProperExceptionIfNeeded(unsigned long const&, unsigned long const&) @ 0x0000000014a4bbd9 6. /build/src/Interpreters/ProcessList.cpp:557: DB::QueryStatus::checkTimeLimit() @ 0x0000000014a4c2cd 7. /build/src/Processors/Executors/PipelineExecutor.cpp:206: DB::PipelineExecutor::finalizeExecution() @ 0x00000000169b13ba 8. /build/src/Processors/Executors/PipelineExecutor.cpp:153: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x00000000169b0584 9. /build/src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:se190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169bfeab 10. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc3d92 11. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fcca080 12. ? @ 0x00007fbc6213eac3 13. ? @ 0x00007fbc621d0850 2025.07.28 12:02:30.223245 [ 4963 ] {} TCPHandler: Code: 394. DB::Exception: Query was cancelled. (QUERY_WAS_CANCELLED), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000000a074fcb 4. /build/src/Interpreters/ProcessList.cpp:567: DB::QueryStatus::throwQueryWasCancelled() const @ 0x0000000014a4bc85 5. /build/src/Interpreters/ProcessList.cpp:520: DB::QueryStatus::throwProperExceptionIfNeeded(unsigned long const&, unsigned long const&) @ 0x0000000014a4bbd9 6. /build/src/Interpreters/ProcessList.cpp:557: DB::QueryStatus::checkTimeLimit() @ 0x0000000014a4c2cd 7. /build/src/Processors/Executors/PipelineExecutor.cpp:206: DB::PipelineExecutor::finalizeExecution() @ 0x00000000169b13ba 8. /build/src/Processors/Executors/PipelineExecutor.cpp:153: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x00000000169b0584 9. /build/src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:se190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169bfeab 10. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc3d92 11. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fcca080 12. ? @ 0x00007fbc6213eac3 13. ? @ 0x00007fbc621d0850 Job's origin stack trace: 0. /build/src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000000fc33b84 1. /build/src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000000fcc2ea7 2. /build/src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fcc535c 3. /build/src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000000fcc584d 4. /build/src/Common/ThreadPool.h:279: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x00000000169bf193 5. /build/src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x00000000169bf518 6. /build/src/Server/TCPHandler.cpp:1237: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x00000000168f1525 7. /build/src/Server/TCPHandler.cpp:678: DB::TCPHandler::runImpl() @ 0x00000000168e68e5 8. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 9. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 10. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 11. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 12. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 13. ? @ 0x00007fbc6213eac3 14. ? @ 0x00007fbc621d0850 2025.07.28 12:02:30.232954 [ 17243 ] {10701f27-d212-49c0-b8ea-052ef364b860} executeQuery: Code: 394. DB::Exception: Query was cancelled. (QUERY_WAS_CANCELLED) (version 25.3.6.10636.altinitytest (altinity build)) (from [::1]:35950) (comment: 02461_cancel_finish_race.sh) (query 1, line 1) (in query: KILL QUERY WHERE current_database = 'test_dtwle8fg' SYNC FORMAT Null), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000000a074fcb 4. /build/src/Interpreters/ProcessList.cpp:567: DB::QueryStatus::throwQueryWasCancelled() const @ 0x0000000014a4bc85 5. /build/src/Interpreters/ProcessList.cpp:520: DB::QueryStatus::throwProperExceptionIfNeeded(unsigned long const&, unsigned long const&) @ 0x0000000014a4bbd9 6. /build/src/Interpreters/ProcessList.cpp:557: DB::QueryStatus::checkTimeLimit() @ 0x0000000014a4c2cd 7. /build/src/Processors/Executors/PipelineExecutor.cpp:206: DB::PipelineExecutor::finalizeExecution() @ 0x00000000169b13ba 8. /build/src/Processors/Executors/PipelineExecutor.cpp:153: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x00000000169b0584 9. /build/src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:se190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169bfeab 10. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc3d92 11. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fcca080 12. ? @ 0x00007fbc6213eac3 13. ? @ 0x00007fbc621d0850 2025.07.28 12:02:30.256305 [ 3977 ] {} test_13.rmt2 (7f9b740d-015c-470e-8cc6-8ba33be0dc63): auto DB::StorageReplicatedMergeTree::processQueueEntry(ReplicatedMergeTreeQueue::SelectedEntryPtr)::(anonymous class)::operator()(LogEntryPtr &) const: Code: 86. DB::HTTPException: Received error from remote server http://146b4357c08d:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Ftest%2F01165%2Ftest_13%2Frmt%2Freplicas%2F1&part=20250728_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.6.10636.altinitytest (altinity build)) '. (RECEIVED_ERROR_FROM_REMOTE_IO_SERVER), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.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 const&, int&&, String const&, unsigned long&&, String const&) @ 0x000000000feda8d9 4. /build/src/IO/HTTPCommon.cpp:104: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x000000000feda6e2 5. /build/src/IO/HTTPCommon.cpp:93: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x000000000feda537 6. /build/src/IO/ReadWriteBufferFromHTTP.cpp:277: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x000000001184a4c4 7. /build/src/IO/ReadWriteBufferFromHTTP.cpp:285: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x000000001184a615 8. /build/src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x000000001184ae59 9. /build/src/IO/ReadWriteBufferFromHTTP.cpp:472: void std::__function::__policy_invoker::__call_impl[abi:se190107]>(std::__function::__policy_storage const*) @ 0x000000001184cedd 10. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001184858b 11. /build/src/IO/ReadWriteBufferFromHTTP.cpp:465: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x000000001184bf0b 12. /build/src/IO/ReadBuffer.h:60: DB::ReadBuffer::next() @ 0x000000000a148c7b 13. /build/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) @ 0x0000000011849fb2 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]>&)>&, 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&) @ 0x0000000011841980 15. /build/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) @ 0x000000001621208e 16. /build/src/Storages/StorageReplicatedMergeTree.cpp:5228: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl[abi:se190107] const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000015f9a5fe 17. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000015ed8bfd 18. /build/src/Storages/StorageReplicatedMergeTree.cpp:2514: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x0000000015ec9aab 19. /build/src/Storages/StorageReplicatedMergeTree.cpp:2349: DB::StorageReplicatedMergeTree::executeLogEntry(DB::ReplicatedMergeTreeLogEntry&) @ 0x0000000015eba91b 20. /build/src/Storages/StorageReplicatedMergeTree.cpp:3876: bool std::__function::__policy_invoker&)>::__call_impl[abi:se190107])::$_1, bool (std::shared_ptr&)>>(std::__function::__policy_storage const*, std::shared_ptr&) @ 0x0000000015f9837e 21. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000165d6fc3 22. /build/src/Storages/StorageReplicatedMergeTree.cpp:3872: DB::StorageReplicatedMergeTree::processQueueEntry(std::shared_ptr) @ 0x0000000015efc18a 23. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001624c1b2 24. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000162f9c70 25. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x00000000162fa55a 26. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc6653 27. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000000fccc4c3 28. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc3d92 29. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fcca080 30. ? @ 0x00007fbc6213eac3 31. ? @ 0x00007fbc621d0850 (version 25.3.6.10636.altinitytest (altinity build)) 2025.07.28 12:02:30.257606 [ 17243 ] {} TCPHandler: Code: 394. DB::Exception: Query was cancelled. (QUERY_WAS_CANCELLED), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000000a074fcb 4. /build/src/Interpreters/ProcessList.cpp:567: DB::QueryStatus::throwQueryWasCancelled() const @ 0x0000000014a4bc85 5. /build/src/Interpreters/ProcessList.cpp:520: DB::QueryStatus::throwProperExceptionIfNeeded(unsigned long const&, unsigned long const&) @ 0x0000000014a4bbd9 6. /build/src/Interpreters/ProcessList.cpp:557: DB::QueryStatus::checkTimeLimit() @ 0x0000000014a4c2cd 7. /build/src/Processors/Executors/PipelineExecutor.cpp:206: DB::PipelineExecutor::finalizeExecution() @ 0x00000000169b13ba 8. /build/src/Processors/Executors/PipelineExecutor.cpp:153: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x00000000169b0584 9. /build/src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:se190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169bfeab 10. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc3d92 11. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fcca080 12. ? @ 0x00007fbc6213eac3 13. ? @ 0x00007fbc621d0850 Job's origin stack trace: 0. /build/src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000000fc33b84 1. /build/src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000000fcc2ea7 2. /build/src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fcc535c 3. /build/src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000000fcc584d 4. /build/src/Common/ThreadPool.h:279: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x00000000169bf193 5. /build/src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x00000000169bf518 6. /build/src/Server/TCPHandler.cpp:1237: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x00000000168f1525 7. /build/src/Server/TCPHandler.cpp:678: DB::TCPHandler::runImpl() @ 0x00000000168e68e5 8. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 9. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 10. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 11. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 12. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 13. ? @ 0x00007fbc6213eac3 14. ? @ 0x00007fbc621d0850 2025.07.28 12:02:30.277547 [ 62325 ] {cf125d0c-5d6c-41c2-8e75-c429bae3aad8} executeQuery: Code: 394. DB::Exception: Query was cancelled. (QUERY_WAS_CANCELLED) (version 25.3.6.10636.altinitytest (altinity build)) (from [::1]:35958) (comment: 02461_cancel_finish_race.sh) (query 1, line 1) (in query: KILL QUERY WHERE current_database = 'test_dtwle8fg' SYNC FORMAT Null), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000000a074fcb 4. /build/src/Interpreters/ProcessList.cpp:567: DB::QueryStatus::throwQueryWasCancelled() const @ 0x0000000014a4bc85 5. /build/src/Interpreters/ProcessList.cpp:520: DB::QueryStatus::throwProperExceptionIfNeeded(unsigned long const&, unsigned long const&) @ 0x0000000014a4bbd9 6. /build/src/Interpreters/ProcessList.cpp:557: DB::QueryStatus::checkTimeLimit() @ 0x0000000014a4c2cd 7. /build/src/Processors/Executors/PipelineExecutor.cpp:206: DB::PipelineExecutor::finalizeExecution() @ 0x00000000169b13ba 8. /build/src/Processors/Executors/PipelineExecutor.cpp:153: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x00000000169b0584 9. /build/src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:se190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169bfeab 10. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc3d92 11. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fcca080 12. ? @ 0x00007fbc6213eac3 13. ? @ 0x00007fbc621d0850 2025.07.28 12:02:30.308336 [ 62325 ] {} TCPHandler: Code: 394. DB::Exception: Query was cancelled. (QUERY_WAS_CANCELLED), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000000a074fcb 4. /build/src/Interpreters/ProcessList.cpp:567: DB::QueryStatus::throwQueryWasCancelled() const @ 0x0000000014a4bc85 5. /build/src/Interpreters/ProcessList.cpp:520: DB::QueryStatus::throwProperExceptionIfNeeded(unsigned long const&, unsigned long const&) @ 0x0000000014a4bbd9 6. /build/src/Interpreters/ProcessList.cpp:557: DB::QueryStatus::checkTimeLimit() @ 0x0000000014a4c2cd 7. /build/src/Processors/Executors/PipelineExecutor.cpp:206: DB::PipelineExecutor::finalizeExecution() @ 0x00000000169b13ba 8. /build/src/Processors/Executors/PipelineExecutor.cpp:153: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x00000000169b0584 9. /build/src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:se190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169bfeab 10. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc3d92 11. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fcca080 12. ? @ 0x00007fbc6213eac3 13. ? @ 0x00007fbc621d0850 Job's origin stack trace: 0. /build/src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000000fc33b84 1. /build/src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000000fcc2ea7 2. /build/src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fcc535c 3. /build/src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000000fcc584d 4. /build/src/Common/ThreadPool.h:279: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x00000000169bf193 5. /build/src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x00000000169bf518 6. /build/src/Server/TCPHandler.cpp:1237: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x00000000168f1525 7. /build/src/Server/TCPHandler.cpp:678: DB::TCPHandler::runImpl() @ 0x00000000168e68e5 8. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 9. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 10. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 11. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 12. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 13. ? @ 0x00007fbc6213eac3 14. ? @ 0x00007fbc621d0850 2025.07.28 12:02:30.388705 [ 4446 ] {} TCPHandler: Code: 394. DB::Exception: Query was cancelled. (QUERY_WAS_CANCELLED), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000000a074fcb 4. /build/src/Interpreters/ProcessList.cpp:567: DB::QueryStatus::throwQueryWasCancelled() const @ 0x0000000014a4bc85 5. /build/src/Interpreters/ProcessList.cpp:520: DB::QueryStatus::throwProperExceptionIfNeeded(unsigned long const&, unsigned long const&) @ 0x0000000014a4bbd9 6. /build/src/Interpreters/ProcessList.cpp:531: DB::QueryStatus::addPipelineExecutor(DB::PipelineExecutor*) @ 0x0000000014a4bd9c 7. /build/src/Processors/Executors/PipelineExecutor.cpp:73: DB::PipelineExecutor::PipelineExecutor(std::shared_ptr, std::allocator>>>&, std::shared_ptr) @ 0x00000000169afe31 8. /build/contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x00000000169c07b5 9. /build/src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x00000000169c0978 10. /build/src/Interpreters/InterpreterKillQueryQuery.cpp:439: DB::InterpreterKillQueryQuery::getSelectResult(String const&, String const&) @ 0x0000000014cf0f04 11. /build/src/Interpreters/InterpreterKillQueryQuery.cpp:222: DB::InterpreterKillQueryQuery::execute() @ 0x0000000014cebde2 12. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88dc9 13. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 14. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 15. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 16. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 17. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 18. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 19. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 20. ? @ 0x00007fbc6213eac3 21. ? @ 0x00007fbc621d0850 2025.07.28 12:02:30.390376 [ 17232 ] {bf9e7ad9-0126-48c5-b6a6-1bae028d3efe} executeQuery: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=1, jobs=1). (CANNOT_SCHEDULE_TASK) (version 25.3.6.10636.altinitytest (altinity build)) (from [::1]:44776) (comment: 01943_query_id_check.sql) (query 9, line 15) (in query: SELECT query FROM system.query_log WHERE initial_query_id = (SELECT * FROM tmp) AND current_database = currentDatabase() LIMIT 1;), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000fccaeeb 4. /build/src/Common/ThreadPool.cpp:275: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000fccc813 5. /build/src/Common/ThreadPool.cpp:323: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fcc7bbc 6. /build/src/Common/ThreadPool.cpp:494: ThreadPoolImpl>::scheduleOrThrowOnError(std::function, Priority) @ 0x000000000fcc7a0e 7. /build/src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::spawnThreadsImpl() @ 0x00000000169b2c0c 8. /build/src/Processors/Executors/PipelineExecutor.cpp:394: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x00000000169b0ba7 9. /build/src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x00000000169b03f4 10. /build/src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:se190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169bfeab 11. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc3d92 12. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fcca080 13. ? @ 0x00007fbc6213eac3 14. ? @ 0x00007fbc621d0850 2025.07.28 12:02:30.478128 [ 4900 ] {afff4949-dfba-4ed6-8ed6-2ee07f682736} executeQuery: Code: 394. DB::Exception: Query was cancelled. (QUERY_WAS_CANCELLED) (version 25.3.6.10636.altinitytest (altinity build)) (from [::1]:36014) (comment: 02461_cancel_finish_race.sh) (query 1, line 1) (in query: KILL QUERY WHERE current_database = 'test_dtwle8fg' SYNC FORMAT Null), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000000a074fcb 4. /build/src/Interpreters/ProcessList.cpp:567: DB::QueryStatus::throwQueryWasCancelled() const @ 0x0000000014a4bc85 5. /build/src/Interpreters/ProcessList.cpp:520: DB::QueryStatus::throwProperExceptionIfNeeded(unsigned long const&, unsigned long const&) @ 0x0000000014a4bbd9 6. /build/src/Interpreters/ProcessList.cpp:557: DB::QueryStatus::checkTimeLimit() @ 0x0000000014a4c2cd 7. /build/src/Processors/Executors/PipelineExecutor.cpp:206: DB::PipelineExecutor::finalizeExecution() @ 0x00000000169b13ba 8. /build/src/Processors/Executors/PipelineExecutor.cpp:153: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x00000000169b0584 9. /build/src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:se190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169bfeab 10. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc3d92 11. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fcca080 12. ? @ 0x00007fbc6213eac3 13. ? @ 0x00007fbc621d0850 2025.07.28 12:02:30.529593 [ 4900 ] {} TCPHandler: Code: 394. DB::Exception: Query was cancelled. (QUERY_WAS_CANCELLED), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000000a074fcb 4. /build/src/Interpreters/ProcessList.cpp:567: DB::QueryStatus::throwQueryWasCancelled() const @ 0x0000000014a4bc85 5. /build/src/Interpreters/ProcessList.cpp:520: DB::QueryStatus::throwProperExceptionIfNeeded(unsigned long const&, unsigned long const&) @ 0x0000000014a4bbd9 6. /build/src/Interpreters/ProcessList.cpp:557: DB::QueryStatus::checkTimeLimit() @ 0x0000000014a4c2cd 7. /build/src/Processors/Executors/PipelineExecutor.cpp:206: DB::PipelineExecutor::finalizeExecution() @ 0x00000000169b13ba 8. /build/src/Processors/Executors/PipelineExecutor.cpp:153: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x00000000169b0584 9. /build/src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:se190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169bfeab 10. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc3d92 11. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fcca080 12. ? @ 0x00007fbc6213eac3 13. ? @ 0x00007fbc621d0850 Job's origin stack trace: 0. /build/src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000000fc33b84 1. /build/src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000000fcc2ea7 2. /build/src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fcc535c 3. /build/src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000000fcc584d 4. /build/src/Common/ThreadPool.h:279: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x00000000169bf193 5. /build/src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x00000000169bf518 6. /build/src/Server/TCPHandler.cpp:1237: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x00000000168f1525 7. /build/src/Server/TCPHandler.cpp:678: DB::TCPHandler::runImpl() @ 0x00000000168e68e5 8. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 9. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 10. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 11. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 12. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 13. ? @ 0x00007fbc6213eac3 14. ? @ 0x00007fbc621d0850 2025.07.28 12:02:30.567727 [ 17232 ] {} 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. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000fccaeeb 4. /build/src/Common/ThreadPool.cpp:275: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000fccc813 5. /build/src/Common/ThreadPool.cpp:323: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fcc7bbc 6. /build/src/Common/ThreadPool.cpp:494: ThreadPoolImpl>::scheduleOrThrowOnError(std::function, Priority) @ 0x000000000fcc7a0e 7. /build/src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::spawnThreadsImpl() @ 0x00000000169b2c0c 8. /build/src/Processors/Executors/PipelineExecutor.cpp:394: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x00000000169b0ba7 9. /build/src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x00000000169b03f4 10. /build/src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:se190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169bfeab 11. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc3d92 12. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fcca080 13. ? @ 0x00007fbc6213eac3 14. ? @ 0x00007fbc621d0850 Job's origin stack trace: 0. /build/src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000000fc33b84 1. /build/src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000000fcc2ea7 2. /build/src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fcc535c 3. /build/src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000000fcc584d 4. /build/src/Common/ThreadPool.h:279: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x00000000169bf193 5. /build/src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x00000000169bf518 6. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:631: DB::QueryAnalyzer::evaluateScalarSubqueryIfNeeded(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000014020b6a 7. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3875: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000014019ed9 8. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3980: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000014018e31 9. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:2925: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000001402fcbd 10. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3838: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000014019a9e 11. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3980: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000014018e31 12. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:2925: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000001402fcbd 13. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3838: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000014019a9e 14. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5630: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000014013941 15. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000140127f9 16. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000014011fce 17. /build/src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000001406ce8a 18. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000014973b42 19. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000001497268d 20. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000014974d24 21. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001492924b 22. /build/src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88641 23. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 24. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 25. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 26. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 27. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 28. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 29. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 30. ? @ 0x00007fbc6213eac3 31. ? @ 0x00007fbc621d0850 2025.07.28 12:02:30.584297 [ 11826 ] {1b7bc3c7-2f5d-4bfe-95c2-de8ace884d05} executeQuery: Code: 394. DB::Exception: Query was cancelled. (QUERY_WAS_CANCELLED) (version 25.3.6.10636.altinitytest (altinity build)) (from [::1]:36092) (comment: 02461_cancel_finish_race.sh) (query 1, line 1) (in query: KILL QUERY WHERE current_database = 'test_dtwle8fg' SYNC FORMAT Null), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000000a074fcb 4. /build/src/Interpreters/ProcessList.cpp:567: DB::QueryStatus::throwQueryWasCancelled() const @ 0x0000000014a4bc85 5. /build/src/Interpreters/ProcessList.cpp:520: DB::QueryStatus::throwProperExceptionIfNeeded(unsigned long const&, unsigned long const&) @ 0x0000000014a4bbd9 6. /build/src/Interpreters/ProcessList.cpp:557: DB::QueryStatus::checkTimeLimit() @ 0x0000000014a4c2cd 7. /build/src/Processors/Executors/PipelineExecutor.cpp:206: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x00000000169b03a3 8. /build/src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:se190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169bfeab 9. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc3d92 10. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fcca080 11. ? @ 0x00007fbc6213eac3 12. ? @ 0x00007fbc621d0850 2025.07.28 12:02:30.586708 [ 5112 ] {} TCPHandler: Code: 394. DB::Exception: Query was cancelled. (QUERY_WAS_CANCELLED), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000000a074fcb 4. /build/src/Interpreters/ProcessList.cpp:567: DB::QueryStatus::throwQueryWasCancelled() const @ 0x0000000014a4bc85 5. /build/src/Interpreters/ProcessList.cpp:520: DB::QueryStatus::throwProperExceptionIfNeeded(unsigned long const&, unsigned long const&) @ 0x0000000014a4bbd9 6. /build/src/Interpreters/ProcessList.cpp:531: DB::QueryStatus::addPipelineExecutor(DB::PipelineExecutor*) @ 0x0000000014a4bd9c 7. /build/src/Processors/Executors/PipelineExecutor.cpp:73: DB::PipelineExecutor::PipelineExecutor(std::shared_ptr, std::allocator>>>&, std::shared_ptr) @ 0x00000000169afe31 8. /build/contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x00000000169c07b5 9. /build/src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x00000000169c0978 10. /build/src/Interpreters/InterpreterKillQueryQuery.cpp:439: DB::InterpreterKillQueryQuery::getSelectResult(String const&, String const&) @ 0x0000000014cf0f04 11. /build/src/Interpreters/InterpreterKillQueryQuery.cpp:222: DB::InterpreterKillQueryQuery::execute() @ 0x0000000014cebde2 12. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88dc9 13. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 14. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 15. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 16. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 17. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 18. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 19. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 20. ? @ 0x00007fbc6213eac3 21. ? @ 0x00007fbc621d0850 2025.07.28 12:02:30.619678 [ 11826 ] {} TCPHandler: Code: 394. DB::Exception: Query was cancelled. (QUERY_WAS_CANCELLED), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000000a074fcb 4. /build/src/Interpreters/ProcessList.cpp:567: DB::QueryStatus::throwQueryWasCancelled() const @ 0x0000000014a4bc85 5. /build/src/Interpreters/ProcessList.cpp:520: DB::QueryStatus::throwProperExceptionIfNeeded(unsigned long const&, unsigned long const&) @ 0x0000000014a4bbd9 6. /build/src/Interpreters/ProcessList.cpp:557: DB::QueryStatus::checkTimeLimit() @ 0x0000000014a4c2cd 7. /build/src/Processors/Executors/PipelineExecutor.cpp:206: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x00000000169b03a3 8. /build/src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:se190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169bfeab 9. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc3d92 10. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fcca080 11. ? @ 0x00007fbc6213eac3 12. ? @ 0x00007fbc621d0850 Job's origin stack trace: 0. /build/src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000000fc33b84 1. /build/src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000000fcc2ea7 2. /build/src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fcc535c 3. /build/src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000000fcc584d 4. /build/src/Common/ThreadPool.h:279: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x00000000169bf193 5. /build/src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x00000000169bf518 6. /build/src/Server/TCPHandler.cpp:1237: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x00000000168f1525 7. /build/src/Server/TCPHandler.cpp:678: DB::TCPHandler::runImpl() @ 0x00000000168e68e5 8. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 9. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 10. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 11. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 12. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 13. ? @ 0x00007fbc6213eac3 14. ? @ 0x00007fbc621d0850 2025.07.28 12:02:30.693324 [ 17256 ] {9387d6ab-3a41-4a24-a240-b45af5f09f61} executeQuery: Code: 394. DB::Exception: Query was cancelled. (QUERY_WAS_CANCELLED) (version 25.3.6.10636.altinitytest (altinity build)) (from [::1]:36078) (comment: 02461_cancel_finish_race.sh) (query 1, line 1) (in query: KILL QUERY WHERE current_database = 'test_dtwle8fg' SYNC FORMAT Null), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000000a074fcb 4. /build/src/Interpreters/ProcessList.cpp:567: DB::QueryStatus::throwQueryWasCancelled() const @ 0x0000000014a4bc85 5. /build/src/Interpreters/ProcessList.cpp:520: DB::QueryStatus::throwProperExceptionIfNeeded(unsigned long const&, unsigned long const&) @ 0x0000000014a4bbd9 6. /build/src/Interpreters/ProcessList.cpp:557: DB::QueryStatus::checkTimeLimit() @ 0x0000000014a4c2cd 7. /build/src/Processors/Executors/PipelineExecutor.cpp:206: DB::PipelineExecutor::finalizeExecution() @ 0x00000000169b13ba 8. /build/src/Processors/Executors/PipelineExecutor.cpp:153: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x00000000169b0584 9. /build/src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:se190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169bfeab 10. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc3d92 11. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fcca080 12. ? @ 0x00007fbc6213eac3 13. ? @ 0x00007fbc621d0850 2025.07.28 12:02:30.713211 [ 62056 ] {69b4ec22-ec0c-4f87-b1ce-258e158065ad} executeQuery: Code: 394. DB::Exception: Query was cancelled. (QUERY_WAS_CANCELLED) (version 25.3.6.10636.altinitytest (altinity build)) (from [::1]:36148) (comment: 02461_cancel_finish_race.sh) (query 1, line 1) (in query: KILL QUERY WHERE current_database = 'test_dtwle8fg' SYNC FORMAT Null), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000000a074fcb 4. /build/src/Interpreters/ProcessList.cpp:567: DB::QueryStatus::throwQueryWasCancelled() const @ 0x0000000014a4bc85 5. /build/src/Interpreters/ProcessList.cpp:520: DB::QueryStatus::throwProperExceptionIfNeeded(unsigned long const&, unsigned long const&) @ 0x0000000014a4bbd9 6. /build/src/Interpreters/ProcessList.cpp:557: DB::QueryStatus::checkTimeLimit() @ 0x0000000014a4c2cd 7. /build/src/Processors/Executors/PipelineExecutor.cpp:206: DB::PipelineExecutor::finalizeExecution() @ 0x00000000169b13ba 8. /build/src/Processors/Executors/PipelineExecutor.cpp:153: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x00000000169b0584 9. /build/src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:se190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169bfeab 10. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc3d92 11. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fcca080 12. ? @ 0x00007fbc6213eac3 13. ? @ 0x00007fbc621d0850 2025.07.28 12:02:30.713877 [ 17256 ] {} TCPHandler: Code: 394. DB::Exception: Query was cancelled. (QUERY_WAS_CANCELLED), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000000a074fcb 4. /build/src/Interpreters/ProcessList.cpp:567: DB::QueryStatus::throwQueryWasCancelled() const @ 0x0000000014a4bc85 5. /build/src/Interpreters/ProcessList.cpp:520: DB::QueryStatus::throwProperExceptionIfNeeded(unsigned long const&, unsigned long const&) @ 0x0000000014a4bbd9 6. /build/src/Interpreters/ProcessList.cpp:557: DB::QueryStatus::checkTimeLimit() @ 0x0000000014a4c2cd 7. /build/src/Processors/Executors/PipelineExecutor.cpp:206: DB::PipelineExecutor::finalizeExecution() @ 0x00000000169b13ba 8. /build/src/Processors/Executors/PipelineExecutor.cpp:153: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x00000000169b0584 9. /build/src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:se190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169bfeab 10. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc3d92 11. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fcca080 12. ? @ 0x00007fbc6213eac3 13. ? @ 0x00007fbc621d0850 Job's origin stack trace: 0. /build/src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000000fc33b84 1. /build/src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000000fcc2ea7 2. /build/src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fcc535c 3. /build/src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000000fcc584d 4. /build/src/Common/ThreadPool.h:279: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x00000000169bf193 5. /build/src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x00000000169bf518 6. /build/src/Server/TCPHandler.cpp:1237: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x00000000168f1525 7. /build/src/Server/TCPHandler.cpp:678: DB::TCPHandler::runImpl() @ 0x00000000168e68e5 8. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 9. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 10. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 11. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 12. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 13. ? @ 0x00007fbc6213eac3 14. ? @ 0x00007fbc621d0850 2025.07.28 12:02:30.727275 [ 62056 ] {} TCPHandler: Code: 394. DB::Exception: Query was cancelled. (QUERY_WAS_CANCELLED), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000000a074fcb 4. /build/src/Interpreters/ProcessList.cpp:567: DB::QueryStatus::throwQueryWasCancelled() const @ 0x0000000014a4bc85 5. /build/src/Interpreters/ProcessList.cpp:520: DB::QueryStatus::throwProperExceptionIfNeeded(unsigned long const&, unsigned long const&) @ 0x0000000014a4bbd9 6. /build/src/Interpreters/ProcessList.cpp:557: DB::QueryStatus::checkTimeLimit() @ 0x0000000014a4c2cd 7. /build/src/Processors/Executors/PipelineExecutor.cpp:206: DB::PipelineExecutor::finalizeExecution() @ 0x00000000169b13ba 8. /build/src/Processors/Executors/PipelineExecutor.cpp:153: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x00000000169b0584 9. /build/src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:se190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169bfeab 10. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc3d92 11. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fcca080 12. ? @ 0x00007fbc6213eac3 13. ? @ 0x00007fbc621d0850 Job's origin stack trace: 0. /build/src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000000fc33b84 1. /build/src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000000fcc2ea7 2. /build/src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fcc535c 3. /build/src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000000fcc584d 4. /build/src/Common/ThreadPool.h:279: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x00000000169bf193 5. /build/src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x00000000169bf518 6. /build/src/Server/TCPHandler.cpp:1237: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x00000000168f1525 7. /build/src/Server/TCPHandler.cpp:678: DB::TCPHandler::runImpl() @ 0x00000000168e68e5 8. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 9. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 10. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 11. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 12. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 13. ? @ 0x00007fbc6213eac3 14. ? @ 0x00007fbc621d0850 2025.07.28 12:02:30.816569 [ 5879 ] {d3d5ecc7-7ab4-4614-b194-ee134daff262} executeQuery: Code: 394. DB::Exception: Query was cancelled. (QUERY_WAS_CANCELLED) (version 25.3.6.10636.altinitytest (altinity build)) (from [::1]:36168) (comment: 02461_cancel_finish_race.sh) (query 1, line 1) (in query: KILL QUERY WHERE current_database = 'test_dtwle8fg' SYNC FORMAT Null), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000000a074fcb 4. /build/src/Interpreters/ProcessList.cpp:567: DB::QueryStatus::throwQueryWasCancelled() const @ 0x0000000014a4bc85 5. /build/src/Interpreters/ProcessList.cpp:520: DB::QueryStatus::throwProperExceptionIfNeeded(unsigned long const&, unsigned long const&) @ 0x0000000014a4bbd9 6. /build/src/Interpreters/ProcessList.cpp:557: DB::QueryStatus::checkTimeLimit() @ 0x0000000014a4c2cd 7. /build/src/Processors/Executors/PipelineExecutor.cpp:206: DB::PipelineExecutor::finalizeExecution() @ 0x00000000169b13ba 8. /build/src/Processors/Executors/PipelineExecutor.cpp:153: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x00000000169b0584 9. /build/src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:se190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169bfeab 10. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc3d92 11. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fcca080 12. ? @ 0x00007fbc6213eac3 13. ? @ 0x00007fbc621d0850 2025.07.28 12:02:30.889570 [ 5879 ] {} TCPHandler: Code: 394. DB::Exception: Query was cancelled. (QUERY_WAS_CANCELLED), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000000a074fcb 4. /build/src/Interpreters/ProcessList.cpp:567: DB::QueryStatus::throwQueryWasCancelled() const @ 0x0000000014a4bc85 5. /build/src/Interpreters/ProcessList.cpp:520: DB::QueryStatus::throwProperExceptionIfNeeded(unsigned long const&, unsigned long const&) @ 0x0000000014a4bbd9 6. /build/src/Interpreters/ProcessList.cpp:557: DB::QueryStatus::checkTimeLimit() @ 0x0000000014a4c2cd 7. /build/src/Processors/Executors/PipelineExecutor.cpp:206: DB::PipelineExecutor::finalizeExecution() @ 0x00000000169b13ba 8. /build/src/Processors/Executors/PipelineExecutor.cpp:153: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x00000000169b0584 9. /build/src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:se190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169bfeab 10. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc3d92 11. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fcca080 12. ? @ 0x00007fbc6213eac3 13. ? @ 0x00007fbc621d0850 Job's origin stack trace: 0. /build/src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000000fc33b84 1. /build/src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000000fcc2ea7 2. /build/src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fcc535c 3. /build/src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000000fcc584d 4. /build/src/Common/ThreadPool.h:279: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x00000000169bf193 5. /build/src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x00000000169bf518 6. /build/src/Server/TCPHandler.cpp:1237: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x00000000168f1525 7. /build/src/Server/TCPHandler.cpp:678: DB::TCPHandler::runImpl() @ 0x00000000168e68e5 8. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 9. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 10. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 11. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 12. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 13. ? @ 0x00007fbc6213eac3 14. ? @ 0x00007fbc621d0850 2025.07.28 12:02:30.971663 [ 62057 ] {f66b0f3d-8188-47d1-b1fa-e61ecb99b55d} executeQuery: Code: 394. DB::Exception: Query was cancelled. (QUERY_WAS_CANCELLED) (version 25.3.6.10636.altinitytest (altinity build)) (from [::1]:36216) (comment: 02461_cancel_finish_race.sh) (query 1, line 1) (in query: KILL QUERY WHERE current_database = 'test_dtwle8fg' SYNC FORMAT Null), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000000a074fcb 4. /build/src/Interpreters/ProcessList.cpp:567: DB::QueryStatus::throwQueryWasCancelled() const @ 0x0000000014a4bc85 5. /build/src/Interpreters/ProcessList.cpp:520: DB::QueryStatus::throwProperExceptionIfNeeded(unsigned long const&, unsigned long const&) @ 0x0000000014a4bbd9 6. /build/src/Interpreters/ProcessList.cpp:557: DB::QueryStatus::checkTimeLimit() @ 0x0000000014a4c2cd 7. /build/src/Processors/Executors/PipelineExecutor.cpp:206: DB::PipelineExecutor::finalizeExecution() @ 0x00000000169b13ba 8. /build/src/Processors/Executors/PipelineExecutor.cpp:153: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x00000000169b0584 9. /build/src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:se190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169bfeab 10. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc3d92 11. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fcca080 12. ? @ 0x00007fbc6213eac3 13. ? @ 0x00007fbc621d0850 2025.07.28 12:02:30.994657 [ 62057 ] {} TCPHandler: Code: 394. DB::Exception: Query was cancelled. (QUERY_WAS_CANCELLED), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000000a074fcb 4. /build/src/Interpreters/ProcessList.cpp:567: DB::QueryStatus::throwQueryWasCancelled() const @ 0x0000000014a4bc85 5. /build/src/Interpreters/ProcessList.cpp:520: DB::QueryStatus::throwProperExceptionIfNeeded(unsigned long const&, unsigned long const&) @ 0x0000000014a4bbd9 6. /build/src/Interpreters/ProcessList.cpp:557: DB::QueryStatus::checkTimeLimit() @ 0x0000000014a4c2cd 7. /build/src/Processors/Executors/PipelineExecutor.cpp:206: DB::PipelineExecutor::finalizeExecution() @ 0x00000000169b13ba 8. /build/src/Processors/Executors/PipelineExecutor.cpp:153: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x00000000169b0584 9. /build/src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:se190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169bfeab 10. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc3d92 11. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fcca080 12. ? @ 0x00007fbc6213eac3 13. ? @ 0x00007fbc621d0850 Job's origin stack trace: 0. /build/src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000000fc33b84 1. /build/src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000000fcc2ea7 2. /build/src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fcc535c 3. /build/src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000000fcc584d 4. /build/src/Common/ThreadPool.h:279: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x00000000169bf193 5. /build/src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x00000000169bf518 6. /build/src/Server/TCPHandler.cpp:1237: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x00000000168f1525 7. /build/src/Server/TCPHandler.cpp:678: DB::TCPHandler::runImpl() @ 0x00000000168e68e5 8. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 9. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 10. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 11. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 12. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 13. ? @ 0x00007fbc6213eac3 14. ? @ 0x00007fbc621d0850 2025.07.28 12:02:31.017518 [ 11826 ] {} TCPHandler: Code: 394. DB::Exception: Query 'd9b6e336-01d1-4e11-996f-231bf4fea79c' is killed in pending state. (QUERY_WAS_CANCELLED), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x000000000a06b56b 4. /build/src/Interpreters/executeQuery.cpp:1522: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c8a4ef 5. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 6. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 7. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 8. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 9. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 10. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 11. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 12. ? @ 0x00007fbc6213eac3 13. ? @ 0x00007fbc621d0850 2025.07.28 12:02:31.045488 [ 62325 ] {5c934d9d-c972-4f27-b8b2-97140a9ac734} executeQuery: Code: 394. DB::Exception: Query was cancelled. (QUERY_WAS_CANCELLED) (version 25.3.6.10636.altinitytest (altinity build)) (from [::1]:36230) (comment: 02461_cancel_finish_race.sh) (query 1, line 1) (in query: KILL QUERY WHERE current_database = 'test_dtwle8fg' SYNC FORMAT Null), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000000a074fcb 4. /build/src/Interpreters/ProcessList.cpp:567: DB::QueryStatus::throwQueryWasCancelled() const @ 0x0000000014a4bc85 5. /build/src/Interpreters/ProcessList.cpp:520: DB::QueryStatus::throwProperExceptionIfNeeded(unsigned long const&, unsigned long const&) @ 0x0000000014a4bbd9 6. /build/src/Interpreters/ProcessList.cpp:557: DB::QueryStatus::checkTimeLimit() @ 0x0000000014a4c2cd 7. /build/src/Processors/Executors/PipelineExecutor.cpp:206: DB::PipelineExecutor::finalizeExecution() @ 0x00000000169b13ba 8. /build/src/Processors/Executors/PipelineExecutor.cpp:153: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x00000000169b0584 9. /build/src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:se190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169bfeab 10. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc3d92 11. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fcca080 12. ? @ 0x00007fbc6213eac3 13. ? @ 0x00007fbc621d0850 2025.07.28 12:02:31.047391 [ 62075 ] {01a0a1e6-1da2-4683-a979-6cb5b4985415} executeQuery: Code: 394. DB::Exception: Query was cancelled. (QUERY_WAS_CANCELLED) (version 25.3.6.10636.altinitytest (altinity build)) (from [::1]:36244) (comment: 02461_cancel_finish_race.sh) (query 1, line 1) (in query: KILL QUERY WHERE current_database = 'test_dtwle8fg' SYNC FORMAT Null), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000000a074fcb 4. /build/src/Interpreters/ProcessList.cpp:567: DB::QueryStatus::throwQueryWasCancelled() const @ 0x0000000014a4bc85 5. /build/src/Interpreters/ProcessList.cpp:520: DB::QueryStatus::throwProperExceptionIfNeeded(unsigned long const&, unsigned long const&) @ 0x0000000014a4bbd9 6. /build/src/Interpreters/ProcessList.cpp:557: DB::QueryStatus::checkTimeLimit() @ 0x0000000014a4c2cd 7. /build/src/Processors/Executors/PipelineExecutor.cpp:206: DB::PipelineExecutor::finalizeExecution() @ 0x00000000169b13ba 8. /build/src/Processors/Executors/PipelineExecutor.cpp:153: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x00000000169b0584 9. /build/src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:se190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169bfeab 10. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc3d92 11. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fcca080 12. ? @ 0x00007fbc6213eac3 13. ? @ 0x00007fbc621d0850 2025.07.28 12:02:31.108653 [ 62325 ] {} TCPHandler: Code: 394. DB::Exception: Query was cancelled. (QUERY_WAS_CANCELLED), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000000a074fcb 4. /build/src/Interpreters/ProcessList.cpp:567: DB::QueryStatus::throwQueryWasCancelled() const @ 0x0000000014a4bc85 5. /build/src/Interpreters/ProcessList.cpp:520: DB::QueryStatus::throwProperExceptionIfNeeded(unsigned long const&, unsigned long const&) @ 0x0000000014a4bbd9 6. /build/src/Interpreters/ProcessList.cpp:557: DB::QueryStatus::checkTimeLimit() @ 0x0000000014a4c2cd 7. /build/src/Processors/Executors/PipelineExecutor.cpp:206: DB::PipelineExecutor::finalizeExecution() @ 0x00000000169b13ba 8. /build/src/Processors/Executors/PipelineExecutor.cpp:153: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x00000000169b0584 9. /build/src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:se190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169bfeab 10. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc3d92 11. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fcca080 12. ? @ 0x00007fbc6213eac3 13. ? @ 0x00007fbc621d0850 Job's origin stack trace: 0. /build/src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000000fc33b84 1. /build/src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000000fcc2ea7 2. /build/src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fcc535c 3. /build/src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000000fcc584d 4. /build/src/Common/ThreadPool.h:279: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x00000000169bf193 5. /build/src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x00000000169bf518 6. /build/src/Server/TCPHandler.cpp:1237: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x00000000168f1525 7. /build/src/Server/TCPHandler.cpp:678: DB::TCPHandler::runImpl() @ 0x00000000168e68e5 8. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 9. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 10. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 11. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 12. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 13. ? @ 0x00007fbc6213eac3 14. ? @ 0x00007fbc621d0850 2025.07.28 12:02:31.122457 [ 62075 ] {} TCPHandler: Code: 394. DB::Exception: Query was cancelled. (QUERY_WAS_CANCELLED), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000000a074fcb 4. /build/src/Interpreters/ProcessList.cpp:567: DB::QueryStatus::throwQueryWasCancelled() const @ 0x0000000014a4bc85 5. /build/src/Interpreters/ProcessList.cpp:520: DB::QueryStatus::throwProperExceptionIfNeeded(unsigned long const&, unsigned long const&) @ 0x0000000014a4bbd9 6. /build/src/Interpreters/ProcessList.cpp:557: DB::QueryStatus::checkTimeLimit() @ 0x0000000014a4c2cd 7. /build/src/Processors/Executors/PipelineExecutor.cpp:206: DB::PipelineExecutor::finalizeExecution() @ 0x00000000169b13ba 8. /build/src/Processors/Executors/PipelineExecutor.cpp:153: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x00000000169b0584 9. /build/src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:se190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169bfeab 10. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc3d92 11. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fcca080 12. ? @ 0x00007fbc6213eac3 13. ? @ 0x00007fbc621d0850 Job's origin stack trace: 0. /build/src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000000fc33b84 1. /build/src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000000fcc2ea7 2. /build/src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fcc535c 3. /build/src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000000fcc584d 4. /build/src/Common/ThreadPool.h:279: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x00000000169bf193 5. /build/src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x00000000169bf518 6. /build/src/Server/TCPHandler.cpp:1237: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x00000000168f1525 7. /build/src/Server/TCPHandler.cpp:678: DB::TCPHandler::runImpl() @ 0x00000000168e68e5 8. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 9. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 10. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 11. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 12. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 13. ? @ 0x00007fbc6213eac3 14. ? @ 0x00007fbc621d0850 2025.07.28 12:02:31.141589 [ 3970 ] {} test_13.rmt2 (7f9b740d-015c-470e-8cc6-8ba33be0dc63): auto DB::StorageReplicatedMergeTree::processQueueEntry(ReplicatedMergeTreeQueue::SelectedEntryPtr)::(anonymous class)::operator()(LogEntryPtr &) const: Code: 86. DB::HTTPException: Received error from remote server http://146b4357c08d:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Ftest%2F01165%2Ftest_13%2Frmt%2Freplicas%2F1&part=20250728_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.6.10636.altinitytest (altinity build)) '. (RECEIVED_ERROR_FROM_REMOTE_IO_SERVER), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.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 const&, int&&, String const&, unsigned long&&, String const&) @ 0x000000000feda8d9 4. /build/src/IO/HTTPCommon.cpp:104: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x000000000feda6e2 5. /build/src/IO/HTTPCommon.cpp:93: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x000000000feda537 6. /build/src/IO/ReadWriteBufferFromHTTP.cpp:277: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x000000001184a4c4 7. /build/src/IO/ReadWriteBufferFromHTTP.cpp:285: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x000000001184a615 8. /build/src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x000000001184ae59 9. /build/src/IO/ReadWriteBufferFromHTTP.cpp:472: void std::__function::__policy_invoker::__call_impl[abi:se190107]>(std::__function::__policy_storage const*) @ 0x000000001184cedd 10. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001184858b 11. /build/src/IO/ReadWriteBufferFromHTTP.cpp:465: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x000000001184bf0b 12. /build/src/IO/ReadBuffer.h:60: DB::ReadBuffer::next() @ 0x000000000a148c7b 13. /build/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) @ 0x0000000011849fb2 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]>&)>&, 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&) @ 0x0000000011841980 15. /build/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) @ 0x000000001621208e 16. /build/src/Storages/StorageReplicatedMergeTree.cpp:5228: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl[abi:se190107] const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000015f9a5fe 17. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000015ed8bfd 18. /build/src/Storages/StorageReplicatedMergeTree.cpp:2514: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x0000000015ec9aab 19. /build/src/Storages/StorageReplicatedMergeTree.cpp:2349: DB::StorageReplicatedMergeTree::executeLogEntry(DB::ReplicatedMergeTreeLogEntry&) @ 0x0000000015eba91b 20. /build/src/Storages/StorageReplicatedMergeTree.cpp:3876: bool std::__function::__policy_invoker&)>::__call_impl[abi:se190107])::$_1, bool (std::shared_ptr&)>>(std::__function::__policy_storage const*, std::shared_ptr&) @ 0x0000000015f9837e 21. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000165d6fc3 22. /build/src/Storages/StorageReplicatedMergeTree.cpp:3872: DB::StorageReplicatedMergeTree::processQueueEntry(std::shared_ptr) @ 0x0000000015efc18a 23. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001624c1b2 24. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000162f9c70 25. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x00000000162fa55a 26. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc6653 27. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000000fccc4c3 28. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc3d92 29. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fcca080 30. ? @ 0x00007fbc6213eac3 31. ? @ 0x00007fbc621d0850 (version 25.3.6.10636.altinitytest (altinity build)) 2025.07.28 12:02:31.165355 [ 62056 ] {398d5d9d-abf5-40bb-9686-d028aa8be289} executeQuery: Code: 394. DB::Exception: Query was cancelled. (QUERY_WAS_CANCELLED) (version 25.3.6.10636.altinitytest (altinity build)) (from [::1]:36340) (comment: 02461_cancel_finish_race.sh) (query 1, line 1) (in query: KILL QUERY WHERE current_database = 'test_dtwle8fg' SYNC FORMAT Null), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000000a074fcb 4. /build/src/Interpreters/ProcessList.cpp:567: DB::QueryStatus::throwQueryWasCancelled() const @ 0x0000000014a4bc85 5. /build/src/Interpreters/ProcessList.cpp:520: DB::QueryStatus::throwProperExceptionIfNeeded(unsigned long const&, unsigned long const&) @ 0x0000000014a4bbd9 6. /build/src/Interpreters/ProcessList.cpp:557: DB::QueryStatus::checkTimeLimit() @ 0x0000000014a4c2cd 7. /build/src/Processors/Executors/PipelineExecutor.cpp:206: DB::PipelineExecutor::finalizeExecution() @ 0x00000000169b13ba 8. /build/src/Processors/Executors/PipelineExecutor.cpp:153: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x00000000169b0584 9. /build/src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:se190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169bfeab 10. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc3d92 11. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fcca080 12. ? @ 0x00007fbc6213eac3 13. ? @ 0x00007fbc621d0850 2025.07.28 12:02:31.185930 [ 62056 ] {} TCPHandler: Code: 394. DB::Exception: Query was cancelled. (QUERY_WAS_CANCELLED), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000000a074fcb 4. /build/src/Interpreters/ProcessList.cpp:567: DB::QueryStatus::throwQueryWasCancelled() const @ 0x0000000014a4bc85 5. /build/src/Interpreters/ProcessList.cpp:520: DB::QueryStatus::throwProperExceptionIfNeeded(unsigned long const&, unsigned long const&) @ 0x0000000014a4bbd9 6. /build/src/Interpreters/ProcessList.cpp:557: DB::QueryStatus::checkTimeLimit() @ 0x0000000014a4c2cd 7. /build/src/Processors/Executors/PipelineExecutor.cpp:206: DB::PipelineExecutor::finalizeExecution() @ 0x00000000169b13ba 8. /build/src/Processors/Executors/PipelineExecutor.cpp:153: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x00000000169b0584 9. /build/src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:se190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169bfeab 10. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc3d92 11. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fcca080 12. ? @ 0x00007fbc6213eac3 13. ? @ 0x00007fbc621d0850 Job's origin stack trace: 0. /build/src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000000fc33b84 1. /build/src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000000fcc2ea7 2. /build/src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fcc535c 3. /build/src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000000fcc584d 4. /build/src/Common/ThreadPool.h:279: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x00000000169bf193 5. /build/src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x00000000169bf518 6. /build/src/Server/TCPHandler.cpp:1237: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x00000000168f1525 7. /build/src/Server/TCPHandler.cpp:678: DB::TCPHandler::runImpl() @ 0x00000000168e68e5 8. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 9. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 10. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 11. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 12. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 13. ? @ 0x00007fbc6213eac3 14. ? @ 0x00007fbc621d0850 2025.07.28 12:02:31.462438 [ 17243 ] {62715434-115a-45bd-95e5-e5d16fd5cce0} executeQuery: Code: 394. DB::Exception: Query was cancelled. (QUERY_WAS_CANCELLED) (version 25.3.6.10636.altinitytest (altinity build)) (from [::1]:36374) (comment: 02461_cancel_finish_race.sh) (query 1, line 1) (in query: KILL QUERY WHERE current_database = 'test_dtwle8fg' SYNC FORMAT Null), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000000a074fcb 4. /build/src/Interpreters/ProcessList.cpp:567: DB::QueryStatus::throwQueryWasCancelled() const @ 0x0000000014a4bc85 5. /build/src/Interpreters/ProcessList.cpp:520: DB::QueryStatus::throwProperExceptionIfNeeded(unsigned long const&, unsigned long const&) @ 0x0000000014a4bbd9 6. /build/src/Interpreters/ProcessList.cpp:557: DB::QueryStatus::checkTimeLimit() @ 0x0000000014a4c2cd 7. /build/src/Processors/Executors/PipelineExecutor.cpp:206: DB::PipelineExecutor::finalizeExecution() @ 0x00000000169b13ba 8. /build/src/Processors/Executors/PipelineExecutor.cpp:153: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x00000000169b0584 9. /build/src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:se190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169bfeab 10. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc3d92 11. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fcca080 12. ? @ 0x00007fbc6213eac3 13. ? @ 0x00007fbc621d0850 2025.07.28 12:02:31.480376 [ 17243 ] {} TCPHandler: Code: 394. DB::Exception: Query was cancelled. (QUERY_WAS_CANCELLED), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000000a074fcb 4. /build/src/Interpreters/ProcessList.cpp:567: DB::QueryStatus::throwQueryWasCancelled() const @ 0x0000000014a4bc85 5. /build/src/Interpreters/ProcessList.cpp:520: DB::QueryStatus::throwProperExceptionIfNeeded(unsigned long const&, unsigned long const&) @ 0x0000000014a4bbd9 6. /build/src/Interpreters/ProcessList.cpp:557: DB::QueryStatus::checkTimeLimit() @ 0x0000000014a4c2cd 7. /build/src/Processors/Executors/PipelineExecutor.cpp:206: DB::PipelineExecutor::finalizeExecution() @ 0x00000000169b13ba 8. /build/src/Processors/Executors/PipelineExecutor.cpp:153: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x00000000169b0584 9. /build/src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:se190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169bfeab 10. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc3d92 11. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fcca080 12. ? @ 0x00007fbc6213eac3 13. ? @ 0x00007fbc621d0850 Job's origin stack trace: 0. /build/src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000000fc33b84 1. /build/src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000000fcc2ea7 2. /build/src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fcc535c 3. /build/src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000000fcc584d 4. /build/src/Common/ThreadPool.h:279: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x00000000169bf193 5. /build/src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x00000000169bf518 6. /build/src/Server/TCPHandler.cpp:1237: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x00000000168f1525 7. /build/src/Server/TCPHandler.cpp:678: DB::TCPHandler::runImpl() @ 0x00000000168e68e5 8. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 9. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 10. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 11. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 12. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 13. ? @ 0x00007fbc6213eac3 14. ? @ 0x00007fbc621d0850 2025.07.28 12:02:31.484661 [ 62114 ] {c51565e7-9fed-4028-b771-7cc81668bb84} executeQuery: Code: 394. DB::Exception: Query was cancelled. (QUERY_WAS_CANCELLED) (version 25.3.6.10636.altinitytest (altinity build)) (from [::1]:36444) (comment: 02461_cancel_finish_race.sh) (query 1, line 1) (in query: KILL QUERY WHERE current_database = 'test_dtwle8fg' SYNC FORMAT Null), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000000a074fcb 4. /build/src/Interpreters/ProcessList.cpp:567: DB::QueryStatus::throwQueryWasCancelled() const @ 0x0000000014a4bc85 5. /build/src/Interpreters/ProcessList.cpp:520: DB::QueryStatus::throwProperExceptionIfNeeded(unsigned long const&, unsigned long const&) @ 0x0000000014a4bbd9 6. /build/src/Interpreters/ProcessList.cpp:531: DB::QueryStatus::addPipelineExecutor(DB::PipelineExecutor*) @ 0x0000000014a4bd9c 7. /build/src/Processors/Executors/PipelineExecutor.cpp:73: DB::PipelineExecutor::PipelineExecutor(std::shared_ptr, std::allocator>>>&, std::shared_ptr) @ 0x00000000169afe31 8. /build/contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x00000000169bef66 9. /build/src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x00000000169bf518 10. /build/src/Server/TCPHandler.cpp:1237: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x00000000168f1525 11. /build/src/Server/TCPHandler.cpp:678: DB::TCPHandler::runImpl() @ 0x00000000168e68e5 12. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 13. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 14. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 16. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 17. ? @ 0x00007fbc6213eac3 18. ? @ 0x00007fbc621d0850 2025.07.28 12:02:31.506254 [ 17371 ] {572cc8b7-2d46-4dab-a639-37309ba3fe78} executeQuery: Code: 394. DB::Exception: Query was cancelled. (QUERY_WAS_CANCELLED) (version 25.3.6.10636.altinitytest (altinity build)) (from [::1]:36412) (comment: 02461_cancel_finish_race.sh) (query 1, line 1) (in query: KILL QUERY WHERE current_database = 'test_dtwle8fg' SYNC FORMAT Null), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000000a074fcb 4. /build/src/Interpreters/ProcessList.cpp:567: DB::QueryStatus::throwQueryWasCancelled() const @ 0x0000000014a4bc85 5. /build/src/Interpreters/ProcessList.cpp:520: DB::QueryStatus::throwProperExceptionIfNeeded(unsigned long const&, unsigned long const&) @ 0x0000000014a4bbd9 6. /build/src/Interpreters/ProcessList.cpp:557: DB::QueryStatus::checkTimeLimit() @ 0x0000000014a4c2cd 7. /build/src/Processors/Executors/PipelineExecutor.cpp:206: DB::PipelineExecutor::finalizeExecution() @ 0x00000000169b13ba 8. /build/src/Processors/Executors/PipelineExecutor.cpp:153: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x00000000169b0584 9. /build/src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:se190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169bfeab 10. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc3d92 11. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fcca080 12. ? @ 0x00007fbc6213eac3 13. ? @ 0x00007fbc621d0850 2025.07.28 12:02:31.509002 [ 62114 ] {} TCPHandler: Code: 394. DB::Exception: Query was cancelled. (QUERY_WAS_CANCELLED), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000000a074fcb 4. /build/src/Interpreters/ProcessList.cpp:567: DB::QueryStatus::throwQueryWasCancelled() const @ 0x0000000014a4bc85 5. /build/src/Interpreters/ProcessList.cpp:520: DB::QueryStatus::throwProperExceptionIfNeeded(unsigned long const&, unsigned long const&) @ 0x0000000014a4bbd9 6. /build/src/Interpreters/ProcessList.cpp:531: DB::QueryStatus::addPipelineExecutor(DB::PipelineExecutor*) @ 0x0000000014a4bd9c 7. /build/src/Processors/Executors/PipelineExecutor.cpp:73: DB::PipelineExecutor::PipelineExecutor(std::shared_ptr, std::allocator>>>&, std::shared_ptr) @ 0x00000000169afe31 8. /build/contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x00000000169bef66 9. /build/src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x00000000169bf518 10. /build/src/Server/TCPHandler.cpp:1237: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x00000000168f1525 11. /build/src/Server/TCPHandler.cpp:678: DB::TCPHandler::runImpl() @ 0x00000000168e68e5 12. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 13. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 14. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 16. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 17. ? @ 0x00007fbc6213eac3 18. ? @ 0x00007fbc621d0850 2025.07.28 12:02:31.531832 [ 17371 ] {} TCPHandler: Code: 394. DB::Exception: Query was cancelled. (QUERY_WAS_CANCELLED), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000000a074fcb 4. /build/src/Interpreters/ProcessList.cpp:567: DB::QueryStatus::throwQueryWasCancelled() const @ 0x0000000014a4bc85 5. /build/src/Interpreters/ProcessList.cpp:520: DB::QueryStatus::throwProperExceptionIfNeeded(unsigned long const&, unsigned long const&) @ 0x0000000014a4bbd9 6. /build/src/Interpreters/ProcessList.cpp:557: DB::QueryStatus::checkTimeLimit() @ 0x0000000014a4c2cd 7. /build/src/Processors/Executors/PipelineExecutor.cpp:206: DB::PipelineExecutor::finalizeExecution() @ 0x00000000169b13ba 8. /build/src/Processors/Executors/PipelineExecutor.cpp:153: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x00000000169b0584 9. /build/src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:se190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169bfeab 10. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc3d92 11. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fcca080 12. ? @ 0x00007fbc6213eac3 13. ? @ 0x00007fbc621d0850 Job's origin stack trace: 0. /build/src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000000fc33b84 1. /build/src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000000fcc2ea7 2. /build/src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fcc535c 3. /build/src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000000fcc584d 4. /build/src/Common/ThreadPool.h:279: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x00000000169bf193 5. /build/src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x00000000169bf518 6. /build/src/Server/TCPHandler.cpp:1237: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x00000000168f1525 7. /build/src/Server/TCPHandler.cpp:678: DB::TCPHandler::runImpl() @ 0x00000000168e68e5 8. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 9. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 10. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 11. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 12. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 13. ? @ 0x00007fbc6213eac3 14. ? @ 0x00007fbc621d0850 2025.07.28 12:02:31.585135 [ 4963 ] {183f7f20-8463-496f-bf6e-e399b173a90b} executeQuery: Code: 394. DB::Exception: Query was cancelled. (QUERY_WAS_CANCELLED) (version 25.3.6.10636.altinitytest (altinity build)) (from [::1]:54314) (comment: 02461_cancel_finish_race.sh) (query 1, line 1) (in query: KILL QUERY WHERE current_database = 'test_dtwle8fg' SYNC FORMAT Null), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000000a074fcb 4. /build/src/Interpreters/ProcessList.cpp:567: DB::QueryStatus::throwQueryWasCancelled() const @ 0x0000000014a4bc85 5. /build/src/Interpreters/ProcessList.cpp:520: DB::QueryStatus::throwProperExceptionIfNeeded(unsigned long const&, unsigned long const&) @ 0x0000000014a4bbd9 6. /build/src/Interpreters/ProcessList.cpp:557: DB::QueryStatus::checkTimeLimit() @ 0x0000000014a4c2cd 7. /build/src/Processors/Executors/PipelineExecutor.cpp:206: DB::PipelineExecutor::finalizeExecution() @ 0x00000000169b13ba 8. /build/src/Processors/Executors/PipelineExecutor.cpp:153: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x00000000169b0584 9. /build/src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:se190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169bfeab 10. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc3d92 11. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fcca080 12. ? @ 0x00007fbc6213eac3 13. ? @ 0x00007fbc621d0850 2025.07.28 12:02:31.590656 [ 4963 ] {} TCPHandler: Code: 394. DB::Exception: Query was cancelled. (QUERY_WAS_CANCELLED), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000000a074fcb 4. /build/src/Interpreters/ProcessList.cpp:567: DB::QueryStatus::throwQueryWasCancelled() const @ 0x0000000014a4bc85 5. /build/src/Interpreters/ProcessList.cpp:520: DB::QueryStatus::throwProperExceptionIfNeeded(unsigned long const&, unsigned long const&) @ 0x0000000014a4bbd9 6. /build/src/Interpreters/ProcessList.cpp:557: DB::QueryStatus::checkTimeLimit() @ 0x0000000014a4c2cd 7. /build/src/Processors/Executors/PipelineExecutor.cpp:206: DB::PipelineExecutor::finalizeExecution() @ 0x00000000169b13ba 8. /build/src/Processors/Executors/PipelineExecutor.cpp:153: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x00000000169b0584 9. /build/src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:se190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169bfeab 10. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc3d92 11. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fcca080 12. ? @ 0x00007fbc6213eac3 13. ? @ 0x00007fbc621d0850 Job's origin stack trace: 0. /build/src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000000fc33b84 1. /build/src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000000fcc2ea7 2. /build/src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fcc535c 3. /build/src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000000fcc584d 4. /build/src/Common/ThreadPool.h:279: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x00000000169bf193 5. /build/src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x00000000169bf518 6. /build/src/Server/TCPHandler.cpp:1237: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x00000000168f1525 7. /build/src/Server/TCPHandler.cpp:678: DB::TCPHandler::runImpl() @ 0x00000000168e68e5 8. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 9. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 10. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 11. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 12. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 13. ? @ 0x00007fbc6213eac3 14. ? @ 0x00007fbc621d0850 2025.07.28 12:02:31.612483 [ 62056 ] {} TCPHandler: Code: 394. DB::Exception: Query 'e1138809-d6eb-4741-b4e5-989f689108b0' is killed in pending state. (QUERY_WAS_CANCELLED), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x000000000a06b56b 4. /build/src/Interpreters/executeQuery.cpp:1522: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c8a4ef 5. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 6. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 7. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 8. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 9. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 10. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 11. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 12. ? @ 0x00007fbc6213eac3 13. ? @ 0x00007fbc621d0850 2025.07.28 12:02:31.632451 [ 62065 ] {} TCPHandler: Code: 394. DB::Exception: Query was cancelled. (QUERY_WAS_CANCELLED), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000000a074fcb 4. /build/src/Interpreters/ProcessList.cpp:567: DB::QueryStatus::throwQueryWasCancelled() const @ 0x0000000014a4bc85 5. /build/src/Interpreters/ProcessList.cpp:520: DB::QueryStatus::throwProperExceptionIfNeeded(unsigned long const&, unsigned long const&) @ 0x0000000014a4bbd9 6. /build/src/Interpreters/ProcessList.cpp:557: DB::QueryStatus::checkTimeLimit() @ 0x0000000014a4c2cd 7. /build/src/Processors/Executors/PipelineExecutor.cpp:206: DB::PipelineExecutor::finalizeExecution() @ 0x00000000169b13ba 8. /build/src/Processors/Executors/PipelineExecutor.cpp:181: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x00000000169b1726 9. /build/src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x00000000169c081c 10. /build/src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x00000000169c0978 11. /build/src/Interpreters/InterpreterKillQueryQuery.cpp:439: DB::InterpreterKillQueryQuery::getSelectResult(String const&, String const&) @ 0x0000000014cf0f04 12. /build/src/Interpreters/InterpreterKillQueryQuery.cpp:222: DB::InterpreterKillQueryQuery::execute() @ 0x0000000014cebde2 13. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88dc9 14. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 15. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 16. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 17. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 18. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 19. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 20. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 21. ? @ 0x00007fbc6213eac3 22. ? @ 0x00007fbc621d0850 2025.07.28 12:02:31.763916 [ 17232 ] {} TCPHandler: Code: 394. DB::Exception: Query was cancelled. (QUERY_WAS_CANCELLED), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000000a074fcb 4. /build/src/Interpreters/ProcessList.cpp:567: DB::QueryStatus::throwQueryWasCancelled() const @ 0x0000000014a4bc85 5. /build/src/Interpreters/ProcessList.cpp:520: DB::QueryStatus::throwProperExceptionIfNeeded(unsigned long const&, unsigned long const&) @ 0x0000000014a4bbd9 6. /build/src/Interpreters/ProcessList.cpp:531: DB::QueryStatus::addPipelineExecutor(DB::PipelineExecutor*) @ 0x0000000014a4bd9c 7. /build/src/Processors/Executors/PipelineExecutor.cpp:73: DB::PipelineExecutor::PipelineExecutor(std::shared_ptr, std::allocator>>>&, std::shared_ptr) @ 0x00000000169afe31 8. /build/contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x00000000169c07b5 9. /build/src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x00000000169c0978 10. /build/src/Interpreters/InterpreterKillQueryQuery.cpp:439: DB::InterpreterKillQueryQuery::getSelectResult(String const&, String const&) @ 0x0000000014cf0f04 11. /build/src/Interpreters/InterpreterKillQueryQuery.cpp:222: DB::InterpreterKillQueryQuery::execute() @ 0x0000000014cebde2 12. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88dc9 13. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 14. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 15. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 16. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 17. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 18. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 19. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 20. ? @ 0x00007fbc6213eac3 21. ? @ 0x00007fbc621d0850 2025.07.28 12:02:31.922599 [ 62103 ] {b7bcf5f4-8a66-4412-8cb6-25d30cef6275} executeQuery: Code: 394. DB::Exception: Query was cancelled. (QUERY_WAS_CANCELLED) (version 25.3.6.10636.altinitytest (altinity build)) (from [::1]:54380) (comment: 02461_cancel_finish_race.sh) (query 1, line 1) (in query: KILL QUERY WHERE current_database = 'test_dtwle8fg' SYNC FORMAT Null), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000000a074fcb 4. /build/src/Interpreters/ProcessList.cpp:567: DB::QueryStatus::throwQueryWasCancelled() const @ 0x0000000014a4bc85 5. /build/src/Interpreters/ProcessList.cpp:520: DB::QueryStatus::throwProperExceptionIfNeeded(unsigned long const&, unsigned long const&) @ 0x0000000014a4bbd9 6. /build/src/Interpreters/ProcessList.cpp:557: DB::QueryStatus::checkTimeLimit() @ 0x0000000014a4c2cd 7. /build/src/Processors/Executors/PipelineExecutor.cpp:206: DB::PipelineExecutor::finalizeExecution() @ 0x00000000169b13ba 8. /build/src/Processors/Executors/PipelineExecutor.cpp:153: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x00000000169b0584 9. /build/src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:se190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169bfeab 10. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc3d92 11. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fcca080 12. ? @ 0x00007fbc6213eac3 13. ? @ 0x00007fbc621d0850 2025.07.28 12:02:31.950089 [ 62103 ] {} TCPHandler: Code: 394. DB::Exception: Query was cancelled. (QUERY_WAS_CANCELLED), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000000a074fcb 4. /build/src/Interpreters/ProcessList.cpp:567: DB::QueryStatus::throwQueryWasCancelled() const @ 0x0000000014a4bc85 5. /build/src/Interpreters/ProcessList.cpp:520: DB::QueryStatus::throwProperExceptionIfNeeded(unsigned long const&, unsigned long const&) @ 0x0000000014a4bbd9 6. /build/src/Interpreters/ProcessList.cpp:557: DB::QueryStatus::checkTimeLimit() @ 0x0000000014a4c2cd 7. /build/src/Processors/Executors/PipelineExecutor.cpp:206: DB::PipelineExecutor::finalizeExecution() @ 0x00000000169b13ba 8. /build/src/Processors/Executors/PipelineExecutor.cpp:153: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x00000000169b0584 9. /build/src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:se190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169bfeab 10. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc3d92 11. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fcca080 12. ? @ 0x00007fbc6213eac3 13. ? @ 0x00007fbc621d0850 Job's origin stack trace: 0. /build/src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000000fc33b84 1. /build/src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000000fcc2ea7 2. /build/src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fcc535c 3. /build/src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000000fcc584d 4. /build/src/Common/ThreadPool.h:279: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x00000000169bf193 5. /build/src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x00000000169bf518 6. /build/src/Server/TCPHandler.cpp:1237: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x00000000168f1525 7. /build/src/Server/TCPHandler.cpp:678: DB::TCPHandler::runImpl() @ 0x00000000168e68e5 8. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 9. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 10. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 11. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 12. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 13. ? @ 0x00007fbc6213eac3 14. ? @ 0x00007fbc621d0850 2025.07.28 12:02:32.055836 [ 62114 ] {} TCPHandler: Code: 394. DB::Exception: Query was cancelled. (QUERY_WAS_CANCELLED), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000000a074fcb 4. /build/src/Interpreters/ProcessList.cpp:567: DB::QueryStatus::throwQueryWasCancelled() const @ 0x0000000014a4bc85 5. /build/src/Interpreters/ProcessList.cpp:520: DB::QueryStatus::throwProperExceptionIfNeeded(unsigned long const&, unsigned long const&) @ 0x0000000014a4bbd9 6. /build/src/Interpreters/ProcessList.cpp:557: DB::QueryStatus::checkTimeLimit() @ 0x0000000014a4c2cd 7. /build/src/Processors/Executors/PipelineExecutor.cpp:206: DB::PipelineExecutor::finalizeExecution() @ 0x00000000169b13ba 8. /build/src/Processors/Executors/PipelineExecutor.cpp:181: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x00000000169b1726 9. /build/src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x00000000169c081c 10. /build/src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x00000000169c0978 11. /build/src/Interpreters/InterpreterKillQueryQuery.cpp:439: DB::InterpreterKillQueryQuery::getSelectResult(String const&, String const&) @ 0x0000000014cf0f04 12. /build/src/Interpreters/InterpreterKillQueryQuery.cpp:222: DB::InterpreterKillQueryQuery::execute() @ 0x0000000014cebde2 13. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88dc9 14. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 15. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 16. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 17. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 18. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 19. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 20. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 21. ? @ 0x00007fbc6213eac3 22. ? @ 0x00007fbc621d0850 2025.07.28 12:02:32.062217 [ 7625 ] {} TCPHandler: Code: 394. DB::Exception: Query was cancelled. (QUERY_WAS_CANCELLED), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000000a074fcb 4. /build/src/Interpreters/ProcessList.cpp:567: DB::QueryStatus::throwQueryWasCancelled() const @ 0x0000000014a4bc85 5. /build/src/Interpreters/ProcessList.cpp:520: DB::QueryStatus::throwProperExceptionIfNeeded(unsigned long const&, unsigned long const&) @ 0x0000000014a4bbd9 6. /build/src/Interpreters/ProcessList.cpp:557: DB::QueryStatus::checkTimeLimit() @ 0x0000000014a4c2cd 7. /build/src/Processors/Executors/PipelineExecutor.cpp:206: DB::PipelineExecutor::finalizeExecution() @ 0x00000000169b13ba 8. /build/src/Processors/Executors/PipelineExecutor.cpp:181: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x00000000169b1726 9. /build/src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x00000000169c081c 10. /build/src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x00000000169c0978 11. /build/src/Interpreters/InterpreterKillQueryQuery.cpp:442: DB::InterpreterKillQueryQuery::getSelectResult(String const&, String const&) @ 0x0000000014cf0f6b 12. /build/src/Interpreters/InterpreterKillQueryQuery.cpp:222: DB::InterpreterKillQueryQuery::execute() @ 0x0000000014cebde2 13. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88dc9 14. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 15. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 16. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 17. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 18. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 19. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 20. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 21. ? @ 0x00007fbc6213eac3 22. ? @ 0x00007fbc621d0850 2025.07.28 12:02:32.083990 [ 3969 ] {} test_13.rmt2 (7f9b740d-015c-470e-8cc6-8ba33be0dc63): auto DB::StorageReplicatedMergeTree::processQueueEntry(ReplicatedMergeTreeQueue::SelectedEntryPtr)::(anonymous class)::operator()(LogEntryPtr &) const: Code: 86. DB::HTTPException: Received error from remote server http://146b4357c08d:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Ftest%2F01165%2Ftest_13%2Frmt%2Freplicas%2F1&part=20250728_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.6.10636.altinitytest (altinity build)) '. (RECEIVED_ERROR_FROM_REMOTE_IO_SERVER), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.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 const&, int&&, String const&, unsigned long&&, String const&) @ 0x000000000feda8d9 4. /build/src/IO/HTTPCommon.cpp:104: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x000000000feda6e2 5. /build/src/IO/HTTPCommon.cpp:93: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x000000000feda537 6. /build/src/IO/ReadWriteBufferFromHTTP.cpp:277: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x000000001184a4c4 7. /build/src/IO/ReadWriteBufferFromHTTP.cpp:285: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x000000001184a615 8. /build/src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x000000001184ae59 9. /build/src/IO/ReadWriteBufferFromHTTP.cpp:472: void std::__function::__policy_invoker::__call_impl[abi:se190107]>(std::__function::__policy_storage const*) @ 0x000000001184cedd 10. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001184858b 11. /build/src/IO/ReadWriteBufferFromHTTP.cpp:465: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x000000001184bf0b 12. /build/src/IO/ReadBuffer.h:60: DB::ReadBuffer::next() @ 0x000000000a148c7b 13. /build/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) @ 0x0000000011849fb2 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]>&)>&, 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&) @ 0x0000000011841980 15. /build/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) @ 0x000000001621208e 16. /build/src/Storages/StorageReplicatedMergeTree.cpp:5228: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl[abi:se190107] const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000015f9a5fe 17. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000015ed8bfd 18. /build/src/Storages/StorageReplicatedMergeTree.cpp:2514: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x0000000015ec9aab 19. /build/src/Storages/StorageReplicatedMergeTree.cpp:2349: DB::StorageReplicatedMergeTree::executeLogEntry(DB::ReplicatedMergeTreeLogEntry&) @ 0x0000000015eba91b 20. /build/src/Storages/StorageReplicatedMergeTree.cpp:3876: bool std::__function::__policy_invoker&)>::__call_impl[abi:se190107])::$_1, bool (std::shared_ptr&)>>(std::__function::__policy_storage const*, std::shared_ptr&) @ 0x0000000015f9837e 21. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000165d6fc3 22. /build/src/Storages/StorageReplicatedMergeTree.cpp:3872: DB::StorageReplicatedMergeTree::processQueueEntry(std::shared_ptr) @ 0x0000000015efc18a 23. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001624c1b2 24. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000162f9c70 25. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x00000000162fa55a 26. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc6653 27. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000000fccc4c3 28. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc3d92 29. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fcca080 30. ? @ 0x00007fbc6213eac3 31. ? @ 0x00007fbc621d0850 (version 25.3.6.10636.altinitytest (altinity build)) 2025.07.28 12:02:32.171983 [ 62053 ] {} TCPHandler: Code: 394. DB::Exception: Query '221bc620-f1e9-485f-a36e-fab3c5ef769d' is killed in pending state. (QUERY_WAS_CANCELLED), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x000000000a06b56b 4. /build/src/Interpreters/executeQuery.cpp:1522: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c8a4ef 5. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 6. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 7. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 8. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 9. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 10. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 11. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 12. ? @ 0x00007fbc6213eac3 13. ? @ 0x00007fbc621d0850 2025.07.28 12:02:32.192433 [ 5879 ] {} TCPHandler: Code: 394. DB::Exception: Query was cancelled. (QUERY_WAS_CANCELLED), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000000a074fcb 4. /build/src/Interpreters/ProcessList.cpp:567: DB::QueryStatus::throwQueryWasCancelled() const @ 0x0000000014a4bc85 5. /build/src/Interpreters/ProcessList.cpp:520: DB::QueryStatus::throwProperExceptionIfNeeded(unsigned long const&, unsigned long const&) @ 0x0000000014a4bbd9 6. /build/src/Interpreters/ProcessList.cpp:531: DB::QueryStatus::addPipelineExecutor(DB::PipelineExecutor*) @ 0x0000000014a4bd9c 7. /build/src/Processors/Executors/PipelineExecutor.cpp:73: DB::PipelineExecutor::PipelineExecutor(std::shared_ptr, std::allocator>>>&, std::shared_ptr) @ 0x00000000169afe31 8. /build/contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x00000000169c07b5 9. /build/src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x00000000169c0978 10. /build/src/Interpreters/InterpreterKillQueryQuery.cpp:439: DB::InterpreterKillQueryQuery::getSelectResult(String const&, String const&) @ 0x0000000014cf0f04 11. /build/src/Interpreters/InterpreterKillQueryQuery.cpp:222: DB::InterpreterKillQueryQuery::execute() @ 0x0000000014cebde2 12. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88dc9 13. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 14. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 15. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 16. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 17. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 18. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 19. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 20. ? @ 0x00007fbc6213eac3 21. ? @ 0x00007fbc621d0850 2025.07.28 12:02:32.388762 [ 62058 ] {} TCPHandler: Code: 394. DB::Exception: Query was cancelled. (QUERY_WAS_CANCELLED), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000000a074fcb 4. /build/src/Interpreters/ProcessList.cpp:567: DB::QueryStatus::throwQueryWasCancelled() const @ 0x0000000014a4bc85 5. /build/src/Interpreters/ProcessList.cpp:520: DB::QueryStatus::throwProperExceptionIfNeeded(unsigned long const&, unsigned long const&) @ 0x0000000014a4bbd9 6. /build/src/Interpreters/ProcessList.cpp:531: DB::QueryStatus::addPipelineExecutor(DB::PipelineExecutor*) @ 0x0000000014a4bd9c 7. /build/src/Processors/Executors/PipelineExecutor.cpp:73: DB::PipelineExecutor::PipelineExecutor(std::shared_ptr, std::allocator>>>&, std::shared_ptr) @ 0x00000000169afe31 8. /build/contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x00000000169c07b5 9. /build/src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x00000000169c0978 10. /build/src/Interpreters/InterpreterKillQueryQuery.cpp:439: DB::InterpreterKillQueryQuery::getSelectResult(String const&, String const&) @ 0x0000000014cf0f04 11. /build/src/Interpreters/InterpreterKillQueryQuery.cpp:222: DB::InterpreterKillQueryQuery::execute() @ 0x0000000014cebde2 12. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88dc9 13. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 14. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 15. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 16. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 17. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 18. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 19. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 20. ? @ 0x00007fbc6213eac3 21. ? @ 0x00007fbc621d0850 2025.07.28 12:02:32.603383 [ 17371 ] {f822131e-6dfb-48cb-bf61-590575fe9eb4} executeQuery: Code: 394. DB::Exception: Query was cancelled. (QUERY_WAS_CANCELLED) (version 25.3.6.10636.altinitytest (altinity build)) (from [::1]:54636) (comment: 02461_cancel_finish_race.sh) (query 1, line 1) (in query: KILL QUERY WHERE current_database = 'test_dtwle8fg' SYNC FORMAT Null), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000000a074fcb 4. /build/src/Interpreters/ProcessList.cpp:567: DB::QueryStatus::throwQueryWasCancelled() const @ 0x0000000014a4bc85 5. /build/src/Interpreters/ProcessList.cpp:520: DB::QueryStatus::throwProperExceptionIfNeeded(unsigned long const&, unsigned long const&) @ 0x0000000014a4bbd9 6. /build/src/Interpreters/ProcessList.cpp:557: DB::QueryStatus::checkTimeLimit() @ 0x0000000014a4c2cd 7. /build/src/Processors/Executors/PipelineExecutor.cpp:206: DB::PipelineExecutor::finalizeExecution() @ 0x00000000169b13ba 8. /build/src/Processors/Executors/PipelineExecutor.cpp:153: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x00000000169b0584 9. /build/src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:se190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169bfeab 10. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc3d92 11. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fcca080 12. ? @ 0x00007fbc6213eac3 13. ? @ 0x00007fbc621d0850 2025.07.28 12:02:32.619777 [ 11826 ] {480f357e-de71-45be-a67d-1dd4a8bac3bc} executeQuery: Code: 394. DB::Exception: Query was cancelled. (QUERY_WAS_CANCELLED) (version 25.3.6.10636.altinitytest (altinity build)) (from [::1]:54594) (comment: 02461_cancel_finish_race.sh) (query 1, line 1) (in query: KILL QUERY WHERE current_database = 'test_dtwle8fg' SYNC FORMAT Null), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000000a074fcb 4. /build/src/Interpreters/ProcessList.cpp:567: DB::QueryStatus::throwQueryWasCancelled() const @ 0x0000000014a4bc85 5. /build/src/Interpreters/ProcessList.cpp:520: DB::QueryStatus::throwProperExceptionIfNeeded(unsigned long const&, unsigned long const&) @ 0x0000000014a4bbd9 6. /build/src/Interpreters/ProcessList.cpp:557: DB::QueryStatus::checkTimeLimit() @ 0x0000000014a4c2cd 7. /build/src/Processors/Executors/PipelineExecutor.cpp:206: DB::PipelineExecutor::finalizeExecution() @ 0x00000000169b13ba 8. /build/src/Processors/Executors/PipelineExecutor.cpp:153: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x00000000169b0584 9. /build/src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:se190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169bfeab 10. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc3d92 11. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fcca080 12. ? @ 0x00007fbc6213eac3 13. ? @ 0x00007fbc621d0850 2025.07.28 12:02:32.622241 [ 17371 ] {} TCPHandler: Code: 394. DB::Exception: Query was cancelled. (QUERY_WAS_CANCELLED), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000000a074fcb 4. /build/src/Interpreters/ProcessList.cpp:567: DB::QueryStatus::throwQueryWasCancelled() const @ 0x0000000014a4bc85 5. /build/src/Interpreters/ProcessList.cpp:520: DB::QueryStatus::throwProperExceptionIfNeeded(unsigned long const&, unsigned long const&) @ 0x0000000014a4bbd9 6. /build/src/Interpreters/ProcessList.cpp:557: DB::QueryStatus::checkTimeLimit() @ 0x0000000014a4c2cd 7. /build/src/Processors/Executors/PipelineExecutor.cpp:206: DB::PipelineExecutor::finalizeExecution() @ 0x00000000169b13ba 8. /build/src/Processors/Executors/PipelineExecutor.cpp:153: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x00000000169b0584 9. /build/src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:se190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169bfeab 10. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc3d92 11. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fcca080 12. ? @ 0x00007fbc6213eac3 13. ? @ 0x00007fbc621d0850 Job's origin stack trace: 0. /build/src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000000fc33b84 1. /build/src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000000fcc2ea7 2. /build/src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fcc535c 3. /build/src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000000fcc584d 4. /build/src/Common/ThreadPool.h:279: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x00000000169bf193 5. /build/src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x00000000169bf518 6. /build/src/Server/TCPHandler.cpp:1237: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x00000000168f1525 7. /build/src/Server/TCPHandler.cpp:678: DB::TCPHandler::runImpl() @ 0x00000000168e68e5 8. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 9. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 10. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 11. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 12. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 13. ? @ 0x00007fbc6213eac3 14. ? @ 0x00007fbc621d0850 2025.07.28 12:02:32.637629 [ 11826 ] {} TCPHandler: Code: 394. DB::Exception: Query was cancelled. (QUERY_WAS_CANCELLED), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000000a074fcb 4. /build/src/Interpreters/ProcessList.cpp:567: DB::QueryStatus::throwQueryWasCancelled() const @ 0x0000000014a4bc85 5. /build/src/Interpreters/ProcessList.cpp:520: DB::QueryStatus::throwProperExceptionIfNeeded(unsigned long const&, unsigned long const&) @ 0x0000000014a4bbd9 6. /build/src/Interpreters/ProcessList.cpp:557: DB::QueryStatus::checkTimeLimit() @ 0x0000000014a4c2cd 7. /build/src/Processors/Executors/PipelineExecutor.cpp:206: DB::PipelineExecutor::finalizeExecution() @ 0x00000000169b13ba 8. /build/src/Processors/Executors/PipelineExecutor.cpp:153: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x00000000169b0584 9. /build/src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:se190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169bfeab 10. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc3d92 11. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fcca080 12. ? @ 0x00007fbc6213eac3 13. ? @ 0x00007fbc621d0850 Job's origin stack trace: 0. /build/src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000000fc33b84 1. /build/src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000000fcc2ea7 2. /build/src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fcc535c 3. /build/src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000000fcc584d 4. /build/src/Common/ThreadPool.h:279: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x00000000169bf193 5. /build/src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x00000000169bf518 6. /build/src/Server/TCPHandler.cpp:1237: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x00000000168f1525 7. /build/src/Server/TCPHandler.cpp:678: DB::TCPHandler::runImpl() @ 0x00000000168e68e5 8. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 9. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 10. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 11. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 12. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 13. ? @ 0x00007fbc6213eac3 14. ? @ 0x00007fbc621d0850 2025.07.28 12:02:32.652349 [ 63425 ] {} TCPHandler: Code: 394. DB::Exception: Query was cancelled. (QUERY_WAS_CANCELLED), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000000a074fcb 4. /build/src/Interpreters/ProcessList.cpp:567: DB::QueryStatus::throwQueryWasCancelled() const @ 0x0000000014a4bc85 5. /build/src/Interpreters/ProcessList.cpp:520: DB::QueryStatus::throwProperExceptionIfNeeded(unsigned long const&, unsigned long const&) @ 0x0000000014a4bbd9 6. /build/src/Interpreters/ProcessList.cpp:531: DB::QueryStatus::addPipelineExecutor(DB::PipelineExecutor*) @ 0x0000000014a4bd9c 7. /build/src/Processors/Executors/PipelineExecutor.cpp:73: DB::PipelineExecutor::PipelineExecutor(std::shared_ptr, std::allocator>>>&, std::shared_ptr) @ 0x00000000169afe31 8. /build/contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x00000000169c07b5 9. /build/src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x00000000169c0978 10. /build/src/Interpreters/InterpreterKillQueryQuery.cpp:439: DB::InterpreterKillQueryQuery::getSelectResult(String const&, String const&) @ 0x0000000014cf0f04 11. /build/src/Interpreters/InterpreterKillQueryQuery.cpp:222: DB::InterpreterKillQueryQuery::execute() @ 0x0000000014cebde2 12. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88dc9 13. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 14. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 15. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 16. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 17. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 18. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 19. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 20. ? @ 0x00007fbc6213eac3 21. ? @ 0x00007fbc621d0850 2025.07.28 12:02:32.681198 [ 62314 ] {} TCPHandler: Code: 394. DB::Exception: Query 'ee16327d-10f5-4d27-b20b-1107073817fd' is killed in pending state. (QUERY_WAS_CANCELLED), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x000000000a06b56b 4. /build/src/Interpreters/executeQuery.cpp:1522: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c8a4ef 5. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 6. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 7. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 8. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 9. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 10. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 11. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 12. ? @ 0x00007fbc6213eac3 13. ? @ 0x00007fbc621d0850 2025.07.28 12:02:32.822014 [ 17243 ] {ce1df981-274b-407f-aa48-195d36428278} executeQuery: Code: 394. DB::Exception: Query was cancelled. (QUERY_WAS_CANCELLED) (version 25.3.6.10636.altinitytest (altinity build)) (from [::1]:54732) (comment: 02461_cancel_finish_race.sh) (query 1, line 1) (in query: KILL QUERY WHERE current_database = 'test_dtwle8fg' SYNC FORMAT Null), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000000a074fcb 4. /build/src/Interpreters/ProcessList.cpp:567: DB::QueryStatus::throwQueryWasCancelled() const @ 0x0000000014a4bc85 5. /build/src/Interpreters/ProcessList.cpp:520: DB::QueryStatus::throwProperExceptionIfNeeded(unsigned long const&, unsigned long const&) @ 0x0000000014a4bbd9 6. /build/src/Interpreters/ProcessList.cpp:557: DB::QueryStatus::checkTimeLimit() @ 0x0000000014a4c2cd 7. /build/src/Processors/Executors/PipelineExecutor.cpp:206: DB::PipelineExecutor::finalizeExecution() @ 0x00000000169b13ba 8. /build/src/Processors/Executors/PipelineExecutor.cpp:153: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x00000000169b0584 9. /build/src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:se190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169bfeab 10. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc3d92 11. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fcca080 12. ? @ 0x00007fbc6213eac3 13. ? @ 0x00007fbc621d0850 2025.07.28 12:02:32.873623 [ 17243 ] {} TCPHandler: Code: 394. DB::Exception: Query was cancelled. (QUERY_WAS_CANCELLED), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000000a074fcb 4. /build/src/Interpreters/ProcessList.cpp:567: DB::QueryStatus::throwQueryWasCancelled() const @ 0x0000000014a4bc85 5. /build/src/Interpreters/ProcessList.cpp:520: DB::QueryStatus::throwProperExceptionIfNeeded(unsigned long const&, unsigned long const&) @ 0x0000000014a4bbd9 6. /build/src/Interpreters/ProcessList.cpp:557: DB::QueryStatus::checkTimeLimit() @ 0x0000000014a4c2cd 7. /build/src/Processors/Executors/PipelineExecutor.cpp:206: DB::PipelineExecutor::finalizeExecution() @ 0x00000000169b13ba 8. /build/src/Processors/Executors/PipelineExecutor.cpp:153: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x00000000169b0584 9. /build/src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:se190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169bfeab 10. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc3d92 11. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fcca080 12. ? @ 0x00007fbc6213eac3 13. ? @ 0x00007fbc621d0850 Job's origin stack trace: 0. /build/src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000000fc33b84 1. /build/src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000000fcc2ea7 2. /build/src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fcc535c 3. /build/src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000000fcc584d 4. /build/src/Common/ThreadPool.h:279: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x00000000169bf193 5. /build/src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x00000000169bf518 6. /build/src/Server/TCPHandler.cpp:1237: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x00000000168f1525 7. /build/src/Server/TCPHandler.cpp:678: DB::TCPHandler::runImpl() @ 0x00000000168e68e5 8. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 9. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 10. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 11. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 12. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 13. ? @ 0x00007fbc6213eac3 14. ? @ 0x00007fbc621d0850 2025.07.28 12:02:32.902947 [ 17611 ] {6482fb5c-9b9b-4c29-a725-b3ddf2b9f6e6} executeQuery: Code: 394. DB::Exception: Query was cancelled. (QUERY_WAS_CANCELLED) (version 25.3.6.10636.altinitytest (altinity build)) (from [::1]:54754) (comment: 02461_cancel_finish_race.sh) (query 1, line 1) (in query: KILL QUERY WHERE current_database = 'test_dtwle8fg' SYNC FORMAT Null), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000000a074fcb 4. /build/src/Interpreters/ProcessList.cpp:567: DB::QueryStatus::throwQueryWasCancelled() const @ 0x0000000014a4bc85 5. /build/src/Interpreters/ProcessList.cpp:520: DB::QueryStatus::throwProperExceptionIfNeeded(unsigned long const&, unsigned long const&) @ 0x0000000014a4bbd9 6. /build/src/Interpreters/ProcessList.cpp:557: DB::QueryStatus::checkTimeLimit() @ 0x0000000014a4c2cd 7. /build/src/Processors/Executors/PipelineExecutor.cpp:206: DB::PipelineExecutor::finalizeExecution() @ 0x00000000169b13ba 8. /build/src/Processors/Executors/PipelineExecutor.cpp:153: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x00000000169b0584 9. /build/src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:se190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169bfeab 10. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc3d92 11. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fcca080 12. ? @ 0x00007fbc6213eac3 13. ? @ 0x00007fbc621d0850 2025.07.28 12:02:32.923241 [ 17611 ] {} TCPHandler: Code: 394. DB::Exception: Query was cancelled. (QUERY_WAS_CANCELLED), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000000a074fcb 4. /build/src/Interpreters/ProcessList.cpp:567: DB::QueryStatus::throwQueryWasCancelled() const @ 0x0000000014a4bc85 5. /build/src/Interpreters/ProcessList.cpp:520: DB::QueryStatus::throwProperExceptionIfNeeded(unsigned long const&, unsigned long const&) @ 0x0000000014a4bbd9 6. /build/src/Interpreters/ProcessList.cpp:557: DB::QueryStatus::checkTimeLimit() @ 0x0000000014a4c2cd 7. /build/src/Processors/Executors/PipelineExecutor.cpp:206: DB::PipelineExecutor::finalizeExecution() @ 0x00000000169b13ba 8. /build/src/Processors/Executors/PipelineExecutor.cpp:153: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x00000000169b0584 9. /build/src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:se190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169bfeab 10. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc3d92 11. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fcca080 12. ? @ 0x00007fbc6213eac3 13. ? @ 0x00007fbc621d0850 Job's origin stack trace: 0. /build/src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000000fc33b84 1. /build/src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000000fcc2ea7 2. /build/src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fcc535c 3. /build/src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000000fcc584d 4. /build/src/Common/ThreadPool.h:279: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x00000000169bf193 5. /build/src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x00000000169bf518 6. /build/src/Server/TCPHandler.cpp:1237: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x00000000168f1525 7. /build/src/Server/TCPHandler.cpp:678: DB::TCPHandler::runImpl() @ 0x00000000168e68e5 8. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 9. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 10. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 11. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 12. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 13. ? @ 0x00007fbc6213eac3 14. ? @ 0x00007fbc621d0850 2025.07.28 12:02:33.204564 [ 4446 ] {} TCPHandler: Code: 394. DB::Exception: Query was cancelled. (QUERY_WAS_CANCELLED), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000000a074fcb 4. /build/src/Interpreters/ProcessList.cpp:567: DB::QueryStatus::throwQueryWasCancelled() const @ 0x0000000014a4bc85 5. /build/src/Interpreters/ProcessList.cpp:520: DB::QueryStatus::throwProperExceptionIfNeeded(unsigned long const&, unsigned long const&) @ 0x0000000014a4bbd9 6. /build/src/Interpreters/ProcessList.cpp:531: DB::QueryStatus::addPipelineExecutor(DB::PipelineExecutor*) @ 0x0000000014a4bd9c 7. /build/src/Processors/Executors/PipelineExecutor.cpp:73: DB::PipelineExecutor::PipelineExecutor(std::shared_ptr, std::allocator>>>&, std::shared_ptr) @ 0x00000000169afe31 8. /build/contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x00000000169c07b5 9. /build/src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x00000000169c0978 10. /build/src/Interpreters/InterpreterKillQueryQuery.cpp:439: DB::InterpreterKillQueryQuery::getSelectResult(String const&, String const&) @ 0x0000000014cf0f04 11. /build/src/Interpreters/InterpreterKillQueryQuery.cpp:222: DB::InterpreterKillQueryQuery::execute() @ 0x0000000014cebde2 12. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88dc9 13. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 14. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 15. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 16. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 17. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 18. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 19. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 20. ? @ 0x00007fbc6213eac3 21. ? @ 0x00007fbc621d0850 2025.07.28 12:02:33.222643 [ 11826 ] {5b7ffc4d-eb5a-4c0a-b749-baabc57ad5a4} executeQuery: Code: 394. DB::Exception: Query was cancelled. (QUERY_WAS_CANCELLED) (version 25.3.6.10636.altinitytest (altinity build)) (from [::1]:54892) (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. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000000a074fcb 4. /build/src/Interpreters/ProcessList.cpp:567: DB::QueryStatus::throwQueryWasCancelled() const @ 0x0000000014a4bc85 5. /build/src/Interpreters/ProcessList.cpp:520: DB::QueryStatus::throwProperExceptionIfNeeded(unsigned long const&, unsigned long const&) @ 0x0000000014a4bbd9 6. /build/src/Interpreters/ProcessList.cpp:557: DB::QueryStatus::checkTimeLimit() @ 0x0000000014a4c2cd 7. /build/src/Processors/Executors/PipelineExecutor.cpp:206: DB::PipelineExecutor::finalizeExecution() @ 0x00000000169b13ba 8. /build/src/Processors/Executors/PipelineExecutor.cpp:153: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x00000000169b0584 9. /build/src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:se190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169bfeab 10. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc3d92 11. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fcca080 12. ? @ 0x00007fbc6213eac3 13. ? @ 0x00007fbc621d0850 2025.07.28 12:02:33.241084 [ 11826 ] {} TCPHandler: Code: 394. DB::Exception: Query was cancelled. (QUERY_WAS_CANCELLED), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000000a074fcb 4. /build/src/Interpreters/ProcessList.cpp:567: DB::QueryStatus::throwQueryWasCancelled() const @ 0x0000000014a4bc85 5. /build/src/Interpreters/ProcessList.cpp:520: DB::QueryStatus::throwProperExceptionIfNeeded(unsigned long const&, unsigned long const&) @ 0x0000000014a4bbd9 6. /build/src/Interpreters/ProcessList.cpp:557: DB::QueryStatus::checkTimeLimit() @ 0x0000000014a4c2cd 7. /build/src/Processors/Executors/PipelineExecutor.cpp:206: DB::PipelineExecutor::finalizeExecution() @ 0x00000000169b13ba 8. /build/src/Processors/Executors/PipelineExecutor.cpp:153: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x00000000169b0584 9. /build/src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:se190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169bfeab 10. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc3d92 11. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fcca080 12. ? @ 0x00007fbc6213eac3 13. ? @ 0x00007fbc621d0850 Job's origin stack trace: 0. /build/src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000000fc33b84 1. /build/src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000000fcc2ea7 2. /build/src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fcc535c 3. /build/src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000000fcc584d 4. /build/src/Common/ThreadPool.h:279: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x00000000169bf193 5. /build/src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x00000000169bf518 6. /build/src/Server/TCPHandler.cpp:1237: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x00000000168f1525 7. /build/src/Server/TCPHandler.cpp:678: DB::TCPHandler::runImpl() @ 0x00000000168e68e5 8. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 9. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 10. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 11. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 12. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 13. ? @ 0x00007fbc6213eac3 14. ? @ 0x00007fbc621d0850 2025.07.28 12:02:33.245674 [ 62325 ] {10e4a232-ae81-4b28-b4a7-7318d43f91c3} executeQuery: Code: 394. DB::Exception: Query was cancelled. (QUERY_WAS_CANCELLED) (version 25.3.6.10636.altinitytest (altinity build)) (from [::1]:54862) (comment: 02461_cancel_finish_race.sh) (query 1, line 1) (in query: KILL QUERY WHERE current_database = 'test_dtwle8fg' SYNC FORMAT Null), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000000a074fcb 4. /build/src/Interpreters/ProcessList.cpp:567: DB::QueryStatus::throwQueryWasCancelled() const @ 0x0000000014a4bc85 5. /build/src/Interpreters/ProcessList.cpp:520: DB::QueryStatus::throwProperExceptionIfNeeded(unsigned long const&, unsigned long const&) @ 0x0000000014a4bbd9 6. /build/src/Interpreters/ProcessList.cpp:557: DB::QueryStatus::checkTimeLimit() @ 0x0000000014a4c2cd 7. /build/src/Processors/Executors/PipelineExecutor.cpp:206: DB::PipelineExecutor::finalizeExecution() @ 0x00000000169b13ba 8. /build/src/Processors/Executors/PipelineExecutor.cpp:153: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x00000000169b0584 9. /build/src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:se190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169bfeab 10. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc3d92 11. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fcca080 12. ? @ 0x00007fbc6213eac3 13. ? @ 0x00007fbc621d0850 2025.07.28 12:02:33.267845 [ 62325 ] {} TCPHandler: Code: 394. DB::Exception: Query was cancelled. (QUERY_WAS_CANCELLED), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000000a074fcb 4. /build/src/Interpreters/ProcessList.cpp:567: DB::QueryStatus::throwQueryWasCancelled() const @ 0x0000000014a4bc85 5. /build/src/Interpreters/ProcessList.cpp:520: DB::QueryStatus::throwProperExceptionIfNeeded(unsigned long const&, unsigned long const&) @ 0x0000000014a4bbd9 6. /build/src/Interpreters/ProcessList.cpp:557: DB::QueryStatus::checkTimeLimit() @ 0x0000000014a4c2cd 7. /build/src/Processors/Executors/PipelineExecutor.cpp:206: DB::PipelineExecutor::finalizeExecution() @ 0x00000000169b13ba 8. /build/src/Processors/Executors/PipelineExecutor.cpp:153: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x00000000169b0584 9. /build/src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:se190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169bfeab 10. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc3d92 11. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fcca080 12. ? @ 0x00007fbc6213eac3 13. ? @ 0x00007fbc621d0850 Job's origin stack trace: 0. /build/src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000000fc33b84 1. /build/src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000000fcc2ea7 2. /build/src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fcc535c 3. /build/src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000000fcc584d 4. /build/src/Common/ThreadPool.h:279: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x00000000169bf193 5. /build/src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x00000000169bf518 6. /build/src/Server/TCPHandler.cpp:1237: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x00000000168f1525 7. /build/src/Server/TCPHandler.cpp:678: DB::TCPHandler::runImpl() @ 0x00000000168e68e5 8. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 9. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 10. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 11. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 12. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 13. ? @ 0x00007fbc6213eac3 14. ? @ 0x00007fbc621d0850 2025.07.28 12:02:33.277187 [ 62075 ] {} TCPHandler: Code: 394. DB::Exception: Query 'f82e7a28-db80-4681-ba77-0272fb1bcdbc' is killed in pending state. (QUERY_WAS_CANCELLED), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x000000000a06b56b 4. /build/src/Interpreters/executeQuery.cpp:1522: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c8a4ef 5. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 6. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 7. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 8. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 9. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 10. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 11. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 12. ? @ 0x00007fbc6213eac3 13. ? @ 0x00007fbc621d0850 2025.07.28 12:02:33.288869 [ 3971 ] {} test_13.rmt2 (7f9b740d-015c-470e-8cc6-8ba33be0dc63): auto DB::StorageReplicatedMergeTree::processQueueEntry(ReplicatedMergeTreeQueue::SelectedEntryPtr)::(anonymous class)::operator()(LogEntryPtr &) const: Code: 86. DB::HTTPException: Received error from remote server http://146b4357c08d:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Ftest%2F01165%2Ftest_13%2Frmt%2Freplicas%2F1&part=20250728_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.6.10636.altinitytest (altinity build)) '. (RECEIVED_ERROR_FROM_REMOTE_IO_SERVER), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.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 const&, int&&, String const&, unsigned long&&, String const&) @ 0x000000000feda8d9 4. /build/src/IO/HTTPCommon.cpp:104: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x000000000feda6e2 5. /build/src/IO/HTTPCommon.cpp:93: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x000000000feda537 6. /build/src/IO/ReadWriteBufferFromHTTP.cpp:277: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x000000001184a4c4 7. /build/src/IO/ReadWriteBufferFromHTTP.cpp:285: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x000000001184a615 8. /build/src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x000000001184ae59 9. /build/src/IO/ReadWriteBufferFromHTTP.cpp:472: void std::__function::__policy_invoker::__call_impl[abi:se190107]>(std::__function::__policy_storage const*) @ 0x000000001184cedd 10. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001184858b 11. /build/src/IO/ReadWriteBufferFromHTTP.cpp:465: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x000000001184bf0b 12. /build/src/IO/ReadBuffer.h:60: DB::ReadBuffer::next() @ 0x000000000a148c7b 13. /build/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) @ 0x0000000011849fb2 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]>&)>&, 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&) @ 0x0000000011841980 15. /build/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) @ 0x000000001621208e 16. /build/src/Storages/StorageReplicatedMergeTree.cpp:5228: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl[abi:se190107] const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000015f9a5fe 17. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000015ed8bfd 18. /build/src/Storages/StorageReplicatedMergeTree.cpp:2514: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x0000000015ec9aab 19. /build/src/Storages/StorageReplicatedMergeTree.cpp:2349: DB::StorageReplicatedMergeTree::executeLogEntry(DB::ReplicatedMergeTreeLogEntry&) @ 0x0000000015eba91b 20. /build/src/Storages/StorageReplicatedMergeTree.cpp:3876: bool std::__function::__policy_invoker&)>::__call_impl[abi:se190107])::$_1, bool (std::shared_ptr&)>>(std::__function::__policy_storage const*, std::shared_ptr&) @ 0x0000000015f9837e 21. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000165d6fc3 22. /build/src/Storages/StorageReplicatedMergeTree.cpp:3872: DB::StorageReplicatedMergeTree::processQueueEntry(std::shared_ptr) @ 0x0000000015efc18a 23. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001624c1b2 24. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000162f9c70 25. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x00000000162fa55a 26. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc6653 27. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000000fccc4c3 28. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc3d92 29. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fcca080 30. ? @ 0x00007fbc6213eac3 31. ? @ 0x00007fbc621d0850 (version 25.3.6.10636.altinitytest (altinity build)) 2025.07.28 12:02:33.290003 [ 5112 ] {927ee1f8-1865-4ce8-b9ca-efaa5c1e6f57} executeQuery: Code: 394. DB::Exception: Query was cancelled. (QUERY_WAS_CANCELLED) (version 25.3.6.10636.altinitytest (altinity build)) (from [::1]:54798) (comment: 02461_cancel_finish_race.sh) (query 1, line 1) (in query: KILL QUERY WHERE current_database = 'test_dtwle8fg' SYNC FORMAT Null), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000000a074fcb 4. /build/src/Interpreters/ProcessList.cpp:567: DB::QueryStatus::throwQueryWasCancelled() const @ 0x0000000014a4bc85 5. /build/src/Interpreters/ProcessList.cpp:520: DB::QueryStatus::throwProperExceptionIfNeeded(unsigned long const&, unsigned long const&) @ 0x0000000014a4bbd9 6. /build/src/Interpreters/ProcessList.cpp:557: DB::QueryStatus::checkTimeLimit() @ 0x0000000014a4c2cd 7. /build/src/Processors/Executors/PipelineExecutor.cpp:206: DB::PipelineExecutor::finalizeExecution() @ 0x00000000169b13ba 8. /build/src/Processors/Executors/PipelineExecutor.cpp:153: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x00000000169b0584 9. /build/src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:se190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169bfeab 10. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc3d92 11. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fcca080 12. ? @ 0x00007fbc6213eac3 13. ? @ 0x00007fbc621d0850 2025.07.28 12:02:33.299307 [ 17203 ] {} TCPHandler: Code: 394. DB::Exception: Query was cancelled. (QUERY_WAS_CANCELLED), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000000a074fcb 4. /build/src/Interpreters/ProcessList.cpp:567: DB::QueryStatus::throwQueryWasCancelled() const @ 0x0000000014a4bc85 5. /build/src/Interpreters/ProcessList.cpp:520: DB::QueryStatus::throwProperExceptionIfNeeded(unsigned long const&, unsigned long const&) @ 0x0000000014a4bbd9 6. /build/src/Interpreters/ProcessList.cpp:531: DB::QueryStatus::addPipelineExecutor(DB::PipelineExecutor*) @ 0x0000000014a4bd9c 7. /build/src/Processors/Executors/PipelineExecutor.cpp:73: DB::PipelineExecutor::PipelineExecutor(std::shared_ptr, std::allocator>>>&, std::shared_ptr) @ 0x00000000169afe31 8. /build/contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x00000000169c07b5 9. /build/src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x00000000169c0978 10. /build/src/Interpreters/InterpreterKillQueryQuery.cpp:439: DB::InterpreterKillQueryQuery::getSelectResult(String const&, String const&) @ 0x0000000014cf0f04 11. /build/src/Interpreters/InterpreterKillQueryQuery.cpp:222: DB::InterpreterKillQueryQuery::execute() @ 0x0000000014cebde2 12. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88dc9 13. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 14. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 15. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 16. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 17. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 18. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 19. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 20. ? @ 0x00007fbc6213eac3 21. ? @ 0x00007fbc621d0850 2025.07.28 12:02:33.319359 [ 5112 ] {} TCPHandler: Code: 394. DB::Exception: Query was cancelled. (QUERY_WAS_CANCELLED), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000000a074fcb 4. /build/src/Interpreters/ProcessList.cpp:567: DB::QueryStatus::throwQueryWasCancelled() const @ 0x0000000014a4bc85 5. /build/src/Interpreters/ProcessList.cpp:520: DB::QueryStatus::throwProperExceptionIfNeeded(unsigned long const&, unsigned long const&) @ 0x0000000014a4bbd9 6. /build/src/Interpreters/ProcessList.cpp:557: DB::QueryStatus::checkTimeLimit() @ 0x0000000014a4c2cd 7. /build/src/Processors/Executors/PipelineExecutor.cpp:206: DB::PipelineExecutor::finalizeExecution() @ 0x00000000169b13ba 8. /build/src/Processors/Executors/PipelineExecutor.cpp:153: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x00000000169b0584 9. /build/src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:se190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169bfeab 10. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc3d92 11. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fcca080 12. ? @ 0x00007fbc6213eac3 13. ? @ 0x00007fbc621d0850 Job's origin stack trace: 0. /build/src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000000fc33b84 1. /build/src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000000fcc2ea7 2. /build/src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fcc535c 3. /build/src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000000fcc584d 4. /build/src/Common/ThreadPool.h:279: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x00000000169bf193 5. /build/src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x00000000169bf518 6. /build/src/Server/TCPHandler.cpp:1237: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x00000000168f1525 7. /build/src/Server/TCPHandler.cpp:678: DB::TCPHandler::runImpl() @ 0x00000000168e68e5 8. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 9. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 10. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 11. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 12. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 13. ? @ 0x00007fbc6213eac3 14. ? @ 0x00007fbc621d0850 2025.07.28 12:02:33.357719 [ 3972 ] {} test_13.rmt2 (7f9b740d-015c-470e-8cc6-8ba33be0dc63): auto DB::StorageReplicatedMergeTree::processQueueEntry(ReplicatedMergeTreeQueue::SelectedEntryPtr)::(anonymous class)::operator()(LogEntryPtr &) const: Code: 86. DB::HTTPException: Received error from remote server http://146b4357c08d:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Ftest%2F01165%2Ftest_13%2Frmt%2Freplicas%2F1&part=20250728_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.6.10636.altinitytest (altinity build)) '. (RECEIVED_ERROR_FROM_REMOTE_IO_SERVER), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.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 const&, int&&, String const&, unsigned long&&, String const&) @ 0x000000000feda8d9 4. /build/src/IO/HTTPCommon.cpp:104: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x000000000feda6e2 5. /build/src/IO/HTTPCommon.cpp:93: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x000000000feda537 6. /build/src/IO/ReadWriteBufferFromHTTP.cpp:277: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x000000001184a4c4 7. /build/src/IO/ReadWriteBufferFromHTTP.cpp:285: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x000000001184a615 8. /build/src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x000000001184ae59 9. /build/src/IO/ReadWriteBufferFromHTTP.cpp:472: void std::__function::__policy_invoker::__call_impl[abi:se190107]>(std::__function::__policy_storage const*) @ 0x000000001184cedd 10. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001184858b 11. /build/src/IO/ReadWriteBufferFromHTTP.cpp:465: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x000000001184bf0b 12. /build/src/IO/ReadBuffer.h:60: DB::ReadBuffer::next() @ 0x000000000a148c7b 13. /build/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) @ 0x0000000011849fb2 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]>&)>&, 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&) @ 0x0000000011841980 15. /build/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) @ 0x000000001621208e 16. /build/src/Storages/StorageReplicatedMergeTree.cpp:5228: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl[abi:se190107] const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000015f9a5fe 17. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000015ed8bfd 18. /build/src/Storages/StorageReplicatedMergeTree.cpp:2514: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x0000000015ec9aab 19. /build/src/Storages/StorageReplicatedMergeTree.cpp:2349: DB::StorageReplicatedMergeTree::executeLogEntry(DB::ReplicatedMergeTreeLogEntry&) @ 0x0000000015eba91b 20. /build/src/Storages/StorageReplicatedMergeTree.cpp:3876: bool std::__function::__policy_invoker&)>::__call_impl[abi:se190107])::$_1, bool (std::shared_ptr&)>>(std::__function::__policy_storage const*, std::shared_ptr&) @ 0x0000000015f9837e 21. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000165d6fc3 22. /build/src/Storages/StorageReplicatedMergeTree.cpp:3872: DB::StorageReplicatedMergeTree::processQueueEntry(std::shared_ptr) @ 0x0000000015efc18a 23. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001624c1b2 24. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000162f9c70 25. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x00000000162fa55a 26. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc6653 27. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000000fccc4c3 28. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc3d92 29. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fcca080 30. ? @ 0x00007fbc6213eac3 31. ? @ 0x00007fbc621d0850 (version 25.3.6.10636.altinitytest (altinity build)) 2025.07.28 12:02:33.420011 [ 62058 ] {c7626323-2c1d-4629-af4c-7f811bb2cb2d} executeQuery: Code: 394. DB::Exception: Query was cancelled. (QUERY_WAS_CANCELLED) (version 25.3.6.10636.altinitytest (altinity build)) (from [::1]:54960) (comment: 02461_cancel_finish_race.sh) (query 1, line 1) (in query: KILL QUERY WHERE current_database = 'test_dtwle8fg' SYNC FORMAT Null), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000000a074fcb 4. /build/src/Interpreters/ProcessList.cpp:567: DB::QueryStatus::throwQueryWasCancelled() const @ 0x0000000014a4bc85 5. /build/src/Interpreters/ProcessList.cpp:520: DB::QueryStatus::throwProperExceptionIfNeeded(unsigned long const&, unsigned long const&) @ 0x0000000014a4bbd9 6. /build/src/Interpreters/ProcessList.cpp:557: DB::QueryStatus::checkTimeLimit() @ 0x0000000014a4c2cd 7. /build/src/Processors/Executors/PipelineExecutor.cpp:206: DB::PipelineExecutor::finalizeExecution() @ 0x00000000169b13ba 8. /build/src/Processors/Executors/PipelineExecutor.cpp:153: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x00000000169b0584 9. /build/src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:se190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169bfeab 10. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc3d92 11. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fcca080 12. ? @ 0x00007fbc6213eac3 13. ? @ 0x00007fbc621d0850 2025.07.28 12:02:33.471120 [ 62058 ] {} TCPHandler: Code: 394. DB::Exception: Query was cancelled. (QUERY_WAS_CANCELLED), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000000a074fcb 4. /build/src/Interpreters/ProcessList.cpp:567: DB::QueryStatus::throwQueryWasCancelled() const @ 0x0000000014a4bc85 5. /build/src/Interpreters/ProcessList.cpp:520: DB::QueryStatus::throwProperExceptionIfNeeded(unsigned long const&, unsigned long const&) @ 0x0000000014a4bbd9 6. /build/src/Interpreters/ProcessList.cpp:557: DB::QueryStatus::checkTimeLimit() @ 0x0000000014a4c2cd 7. /build/src/Processors/Executors/PipelineExecutor.cpp:206: DB::PipelineExecutor::finalizeExecution() @ 0x00000000169b13ba 8. /build/src/Processors/Executors/PipelineExecutor.cpp:153: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x00000000169b0584 9. /build/src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:se190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169bfeab 10. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc3d92 11. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fcca080 12. ? @ 0x00007fbc6213eac3 13. ? @ 0x00007fbc621d0850 Job's origin stack trace: 0. /build/src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000000fc33b84 1. /build/src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000000fcc2ea7 2. /build/src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fcc535c 3. /build/src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000000fcc584d 4. /build/src/Common/ThreadPool.h:279: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x00000000169bf193 5. /build/src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x00000000169bf518 6. /build/src/Server/TCPHandler.cpp:1237: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x00000000168f1525 7. /build/src/Server/TCPHandler.cpp:678: DB::TCPHandler::runImpl() @ 0x00000000168e68e5 8. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 9. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 10. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 11. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 12. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 13. ? @ 0x00007fbc6213eac3 14. ? @ 0x00007fbc621d0850 2025.07.28 12:02:33.471826 [ 17256 ] {} TCPHandler: Code: 394. DB::Exception: Query was cancelled. (QUERY_WAS_CANCELLED), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000000a074fcb 4. /build/src/Interpreters/ProcessList.cpp:567: DB::QueryStatus::throwQueryWasCancelled() const @ 0x0000000014a4bc85 5. /build/src/Interpreters/ProcessList.cpp:520: DB::QueryStatus::throwProperExceptionIfNeeded(unsigned long const&, unsigned long const&) @ 0x0000000014a4bbd9 6. /build/src/Interpreters/ProcessList.cpp:557: DB::QueryStatus::checkTimeLimit() @ 0x0000000014a4c2cd 7. /build/src/Processors/Executors/PipelineExecutor.cpp:206: DB::PipelineExecutor::finalizeExecution() @ 0x00000000169b13ba 8. /build/src/Processors/Executors/PipelineExecutor.cpp:181: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x00000000169b1726 9. /build/src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x00000000169c081c 10. /build/src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x00000000169c0978 11. /build/src/Interpreters/InterpreterKillQueryQuery.cpp:439: DB::InterpreterKillQueryQuery::getSelectResult(String const&, String const&) @ 0x0000000014cf0f04 12. /build/src/Interpreters/InterpreterKillQueryQuery.cpp:222: DB::InterpreterKillQueryQuery::execute() @ 0x0000000014cebde2 13. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88dc9 14. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 15. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 16. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 17. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 18. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 19. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 20. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 21. ? @ 0x00007fbc6213eac3 22. ? @ 0x00007fbc621d0850 2025.07.28 12:02:33.518858 [ 17232 ] {3150b043-be64-4634-ac7e-c0e4715ead86} executeQuery: Code: 394. DB::Exception: Query was cancelled. (QUERY_WAS_CANCELLED) (version 25.3.6.10636.altinitytest (altinity build)) (from [::1]:54878) (comment: 02461_cancel_finish_race.sh) (query 1, line 1) (in query: KILL QUERY WHERE current_database = 'test_dtwle8fg' SYNC FORMAT Null), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000000a074fcb 4. /build/src/Interpreters/ProcessList.cpp:567: DB::QueryStatus::throwQueryWasCancelled() const @ 0x0000000014a4bc85 5. /build/src/Interpreters/ProcessList.cpp:520: DB::QueryStatus::throwProperExceptionIfNeeded(unsigned long const&, unsigned long const&) @ 0x0000000014a4bbd9 6. /build/src/Interpreters/ProcessList.cpp:557: DB::QueryStatus::checkTimeLimit() @ 0x0000000014a4c2cd 7. /build/src/Processors/Executors/PipelineExecutor.cpp:206: DB::PipelineExecutor::finalizeExecution() @ 0x00000000169b13ba 8. /build/src/Processors/Executors/PipelineExecutor.cpp:153: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x00000000169b0584 9. /build/src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:se190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169bfeab 10. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc3d92 11. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fcca080 12. ? @ 0x00007fbc6213eac3 13. ? @ 0x00007fbc621d0850 2025.07.28 12:02:33.576430 [ 17232 ] {} TCPHandler: Code: 394. DB::Exception: Query was cancelled. (QUERY_WAS_CANCELLED), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000000a074fcb 4. /build/src/Interpreters/ProcessList.cpp:567: DB::QueryStatus::throwQueryWasCancelled() const @ 0x0000000014a4bc85 5. /build/src/Interpreters/ProcessList.cpp:520: DB::QueryStatus::throwProperExceptionIfNeeded(unsigned long const&, unsigned long const&) @ 0x0000000014a4bbd9 6. /build/src/Interpreters/ProcessList.cpp:557: DB::QueryStatus::checkTimeLimit() @ 0x0000000014a4c2cd 7. /build/src/Processors/Executors/PipelineExecutor.cpp:206: DB::PipelineExecutor::finalizeExecution() @ 0x00000000169b13ba 8. /build/src/Processors/Executors/PipelineExecutor.cpp:153: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x00000000169b0584 9. /build/src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:se190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169bfeab 10. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc3d92 11. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fcca080 12. ? @ 0x00007fbc6213eac3 13. ? @ 0x00007fbc621d0850 Job's origin stack trace: 0. /build/src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000000fc33b84 1. /build/src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000000fcc2ea7 2. /build/src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fcc535c 3. /build/src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000000fcc584d 4. /build/src/Common/ThreadPool.h:279: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x00000000169bf193 5. /build/src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x00000000169bf518 6. /build/src/Server/TCPHandler.cpp:1237: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x00000000168f1525 7. /build/src/Server/TCPHandler.cpp:678: DB::TCPHandler::runImpl() @ 0x00000000168e68e5 8. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 9. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 10. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 11. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 12. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 13. ? @ 0x00007fbc6213eac3 14. ? @ 0x00007fbc621d0850 2025.07.28 12:02:33.661493 [ 4900 ] {8048948c-ef6d-45b3-8331-be71324cd585} executeQuery: Code: 48. DB::Exception: WITH TOTALS and WITH ROLLUP or CUBE are not supported together in presence of QUALIFY. (NOT_IMPLEMENTED) (version 25.3.6.10636.altinitytest (altinity build)) (from [::1]:36286) (comment: 03095_window_functions_qualify.sql) (query 15, line 30) (in query: SELECT number % toUInt256(2) AS key, count() FROM numbers(10) GROUP BY key WITH CUBE WITH TOTALS QUALIFY key = toNullable(toNullable(0));), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000000a074fcb 4. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5480: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000140156ef 5. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000140127f9 6. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000014011fce 7. /build/src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000001406ce8a 8. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000014973b42 9. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000001497268d 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000014974d24 11. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001492924b 12. /build/src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88641 13. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 14. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 15. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 16. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 17. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 18. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 19. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 20. ? @ 0x00007fbc6213eac3 21. ? @ 0x00007fbc621d0850 2025.07.28 12:02:33.673803 [ 5112 ] {db1f71cd-a3f9-4511-8caa-43a07f7af0fc} executeQuery: Code: 394. DB::Exception: Query was cancelled. (QUERY_WAS_CANCELLED) (version 25.3.6.10636.altinitytest (altinity build)) (from [::1]:55088) (comment: 02461_cancel_finish_race.sh) (query 1, line 1) (in query: KILL QUERY WHERE current_database = 'test_dtwle8fg' SYNC FORMAT Null), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000000a074fcb 4. /build/src/Interpreters/ProcessList.cpp:567: DB::QueryStatus::throwQueryWasCancelled() const @ 0x0000000014a4bc85 5. /build/src/Interpreters/ProcessList.cpp:520: DB::QueryStatus::throwProperExceptionIfNeeded(unsigned long const&, unsigned long const&) @ 0x0000000014a4bbd9 6. /build/src/Interpreters/ProcessList.cpp:557: DB::QueryStatus::checkTimeLimit() @ 0x0000000014a4c2cd 7. /build/src/Processors/Executors/PipelineExecutor.cpp:206: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x00000000169b03a3 8. /build/src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:se190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169bfeab 9. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc3d92 10. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fcca080 11. ? @ 0x00007fbc6213eac3 12. ? @ 0x00007fbc621d0850 2025.07.28 12:02:33.695898 [ 4900 ] {} TCPHandler: Code: 48. DB::Exception: WITH TOTALS and WITH ROLLUP or CUBE are not supported together in presence of QUALIFY. (NOT_IMPLEMENTED), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000000a074fcb 4. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5480: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000140156ef 5. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000140127f9 6. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000014011fce 7. /build/src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000001406ce8a 8. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000014973b42 9. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000001497268d 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000014974d24 11. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001492924b 12. /build/src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88641 13. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 14. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 15. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 16. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 17. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 18. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 19. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 20. ? @ 0x00007fbc6213eac3 21. ? @ 0x00007fbc621d0850 2025.07.28 12:02:33.700574 [ 5112 ] {} TCPHandler: Code: 394. DB::Exception: Query was cancelled. (QUERY_WAS_CANCELLED), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000000a074fcb 4. /build/src/Interpreters/ProcessList.cpp:567: DB::QueryStatus::throwQueryWasCancelled() const @ 0x0000000014a4bc85 5. /build/src/Interpreters/ProcessList.cpp:520: DB::QueryStatus::throwProperExceptionIfNeeded(unsigned long const&, unsigned long const&) @ 0x0000000014a4bbd9 6. /build/src/Interpreters/ProcessList.cpp:557: DB::QueryStatus::checkTimeLimit() @ 0x0000000014a4c2cd 7. /build/src/Processors/Executors/PipelineExecutor.cpp:206: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x00000000169b03a3 8. /build/src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:se190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169bfeab 9. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc3d92 10. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fcca080 11. ? @ 0x00007fbc6213eac3 12. ? @ 0x00007fbc621d0850 Job's origin stack trace: 0. /build/src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000000fc33b84 1. /build/src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000000fcc2ea7 2. /build/src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fcc535c 3. /build/src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000000fcc584d 4. /build/src/Common/ThreadPool.h:279: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x00000000169bf193 5. /build/src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x00000000169bf518 6. /build/src/Server/TCPHandler.cpp:1237: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x00000000168f1525 7. /build/src/Server/TCPHandler.cpp:678: DB::TCPHandler::runImpl() @ 0x00000000168e68e5 8. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 9. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 10. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 11. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 12. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 13. ? @ 0x00007fbc6213eac3 14. ? @ 0x00007fbc621d0850 2025.07.28 12:02:33.852501 [ 17611 ] {693bcf20-7a60-479a-8dd7-79c1f4e9050c} executeQuery: Code: 394. DB::Exception: Query was cancelled. (QUERY_WAS_CANCELLED) (version 25.3.6.10636.altinitytest (altinity build)) (from [::1]:55074) (comment: 02461_cancel_finish_race.sh) (query 1, line 1) (in query: KILL QUERY WHERE current_database = 'test_dtwle8fg' SYNC FORMAT Null), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000000a074fcb 4. /build/src/Interpreters/ProcessList.cpp:567: DB::QueryStatus::throwQueryWasCancelled() const @ 0x0000000014a4bc85 5. /build/src/Interpreters/ProcessList.cpp:520: DB::QueryStatus::throwProperExceptionIfNeeded(unsigned long const&, unsigned long const&) @ 0x0000000014a4bbd9 6. /build/src/Interpreters/ProcessList.cpp:557: DB::QueryStatus::checkTimeLimit() @ 0x0000000014a4c2cd 7. /build/src/Processors/Executors/PipelineExecutor.cpp:206: DB::PipelineExecutor::finalizeExecution() @ 0x00000000169b13ba 8. /build/src/Processors/Executors/PipelineExecutor.cpp:153: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x00000000169b0584 9. /build/src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:se190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169bfeab 10. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc3d92 11. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fcca080 12. ? @ 0x00007fbc6213eac3 13. ? @ 0x00007fbc621d0850 2025.07.28 12:02:33.855861 [ 62093 ] {500c0810-39c9-4c0d-bc8c-1e649fa8dc97} executeQuery: Code: 394. DB::Exception: Query was cancelled. (QUERY_WAS_CANCELLED) (version 25.3.6.10636.altinitytest (altinity build)) (from [::1]:55114) (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. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000000a074fcb 4. /build/src/Interpreters/ProcessList.cpp:567: DB::QueryStatus::throwQueryWasCancelled() const @ 0x0000000014a4bc85 5. /build/src/Interpreters/ProcessList.cpp:520: DB::QueryStatus::throwProperExceptionIfNeeded(unsigned long const&, unsigned long const&) @ 0x0000000014a4bbd9 6. /build/src/Interpreters/ProcessList.cpp:557: DB::QueryStatus::checkTimeLimit() @ 0x0000000014a4c2cd 7. /build/src/Processors/Executors/PipelineExecutor.cpp:206: DB::PipelineExecutor::finalizeExecution() @ 0x00000000169b13ba 8. /build/src/Processors/Executors/PipelineExecutor.cpp:153: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x00000000169b0584 9. /build/src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:se190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169bfeab 10. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc3d92 11. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fcca080 12. ? @ 0x00007fbc6213eac3 13. ? @ 0x00007fbc621d0850 2025.07.28 12:02:33.882174 [ 62093 ] {} TCPHandler: Code: 394. DB::Exception: Query was cancelled. (QUERY_WAS_CANCELLED), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000000a074fcb 4. /build/src/Interpreters/ProcessList.cpp:567: DB::QueryStatus::throwQueryWasCancelled() const @ 0x0000000014a4bc85 5. /build/src/Interpreters/ProcessList.cpp:520: DB::QueryStatus::throwProperExceptionIfNeeded(unsigned long const&, unsigned long const&) @ 0x0000000014a4bbd9 6. /build/src/Interpreters/ProcessList.cpp:557: DB::QueryStatus::checkTimeLimit() @ 0x0000000014a4c2cd 7. /build/src/Processors/Executors/PipelineExecutor.cpp:206: DB::PipelineExecutor::finalizeExecution() @ 0x00000000169b13ba 8. /build/src/Processors/Executors/PipelineExecutor.cpp:153: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x00000000169b0584 9. /build/src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:se190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169bfeab 10. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc3d92 11. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fcca080 12. ? @ 0x00007fbc6213eac3 13. ? @ 0x00007fbc621d0850 Job's origin stack trace: 0. /build/src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000000fc33b84 1. /build/src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000000fcc2ea7 2. /build/src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fcc535c 3. /build/src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000000fcc584d 4. /build/src/Common/ThreadPool.h:279: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x00000000169bf193 5. /build/src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x00000000169bf518 6. /build/src/Server/TCPHandler.cpp:1237: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x00000000168f1525 7. /build/src/Server/TCPHandler.cpp:678: DB::TCPHandler::runImpl() @ 0x00000000168e68e5 8. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 9. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 10. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 11. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 12. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 13. ? @ 0x00007fbc6213eac3 14. ? @ 0x00007fbc621d0850 2025.07.28 12:02:33.887461 [ 4900 ] {0051d651-dbb5-4e42-a5df-ed59ea518f2f} executeQuery: Code: 48. DB::Exception: WITH TOTALS and WITH ROLLUP or CUBE are not supported together in presence of QUALIFY. (NOT_IMPLEMENTED) (version 25.3.6.10636.altinitytest (altinity build)) (from [::1]:36286) (comment: 03095_window_functions_qualify.sql) (query 16, line 32) (in query: SELECT number % 2 AS key, count(materialize(5)) IGNORE NULLS FROM numbers(10) WHERE toLowCardinality(toLowCardinality(materialize(2))) GROUP BY key WITH CUBE WITH TOTALS QUALIFY key = 0;), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000000a074fcb 4. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5480: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000140156ef 5. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000140127f9 6. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000014011fce 7. /build/src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000001406ce8a 8. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000014973b42 9. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000001497268d 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000014974d24 11. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001492924b 12. /build/src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88641 13. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 14. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 15. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 16. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 17. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 18. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 19. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 20. ? @ 0x00007fbc6213eac3 21. ? @ 0x00007fbc621d0850 2025.07.28 12:02:33.887391 [ 17611 ] {} TCPHandler: Code: 394. DB::Exception: Query was cancelled. (QUERY_WAS_CANCELLED), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000000a074fcb 4. /build/src/Interpreters/ProcessList.cpp:567: DB::QueryStatus::throwQueryWasCancelled() const @ 0x0000000014a4bc85 5. /build/src/Interpreters/ProcessList.cpp:520: DB::QueryStatus::throwProperExceptionIfNeeded(unsigned long const&, unsigned long const&) @ 0x0000000014a4bbd9 6. /build/src/Interpreters/ProcessList.cpp:557: DB::QueryStatus::checkTimeLimit() @ 0x0000000014a4c2cd 7. /build/src/Processors/Executors/PipelineExecutor.cpp:206: DB::PipelineExecutor::finalizeExecution() @ 0x00000000169b13ba 8. /build/src/Processors/Executors/PipelineExecutor.cpp:153: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x00000000169b0584 9. /build/src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:se190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169bfeab 10. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc3d92 11. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fcca080 12. ? @ 0x00007fbc6213eac3 13. ? @ 0x00007fbc621d0850 Job's origin stack trace: 0. /build/src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000000fc33b84 1. /build/src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000000fcc2ea7 2. /build/src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fcc535c 3. /build/src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000000fcc584d 4. /build/src/Common/ThreadPool.h:279: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x00000000169bf193 5. /build/src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x00000000169bf518 6. /build/src/Server/TCPHandler.cpp:1237: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x00000000168f1525 7. /build/src/Server/TCPHandler.cpp:678: DB::TCPHandler::runImpl() @ 0x00000000168e68e5 8. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 9. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 10. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 11. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 12. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 13. ? @ 0x00007fbc6213eac3 14. ? @ 0x00007fbc621d0850 2025.07.28 12:02:33.907149 [ 62057 ] {} TCPHandler: Code: 394. DB::Exception: Query was cancelled. (QUERY_WAS_CANCELLED), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000000a074fcb 4. /build/src/Interpreters/ProcessList.cpp:567: DB::QueryStatus::throwQueryWasCancelled() const @ 0x0000000014a4bc85 5. /build/src/Interpreters/ProcessList.cpp:520: DB::QueryStatus::throwProperExceptionIfNeeded(unsigned long const&, unsigned long const&) @ 0x0000000014a4bbd9 6. /build/src/Interpreters/ProcessList.cpp:557: DB::QueryStatus::checkTimeLimit() @ 0x0000000014a4c2cd 7. /build/src/Processors/Executors/PipelineExecutor.cpp:206: DB::PipelineExecutor::finalizeExecution() @ 0x00000000169b13ba 8. /build/src/Processors/Executors/PipelineExecutor.cpp:181: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x00000000169b1726 9. /build/src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x00000000169c081c 10. /build/src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x00000000169c0978 11. /build/src/Interpreters/InterpreterKillQueryQuery.cpp:439: DB::InterpreterKillQueryQuery::getSelectResult(String const&, String const&) @ 0x0000000014cf0f04 12. /build/src/Interpreters/InterpreterKillQueryQuery.cpp:222: DB::InterpreterKillQueryQuery::execute() @ 0x0000000014cebde2 13. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88dc9 14. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 15. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 16. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 17. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 18. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 19. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 20. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 21. ? @ 0x00007fbc6213eac3 22. ? @ 0x00007fbc621d0850 2025.07.28 12:02:33.921668 [ 4900 ] {} TCPHandler: Code: 48. DB::Exception: WITH TOTALS and WITH ROLLUP or CUBE are not supported together in presence of QUALIFY. (NOT_IMPLEMENTED), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000000a074fcb 4. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5480: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000140156ef 5. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000140127f9 6. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000014011fce 7. /build/src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000001406ce8a 8. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000014973b42 9. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000001497268d 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000014974d24 11. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001492924b 12. /build/src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88641 13. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 14. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 15. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 16. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 17. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 18. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 19. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 20. ? @ 0x00007fbc6213eac3 21. ? @ 0x00007fbc621d0850 2025.07.28 12:02:33.936048 [ 11826 ] {} TCPHandler: Code: 394. DB::Exception: Query was cancelled. (QUERY_WAS_CANCELLED), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000000a074fcb 4. /build/src/Interpreters/ProcessList.cpp:567: DB::QueryStatus::throwQueryWasCancelled() const @ 0x0000000014a4bc85 5. /build/src/Interpreters/ProcessList.cpp:520: DB::QueryStatus::throwProperExceptionIfNeeded(unsigned long const&, unsigned long const&) @ 0x0000000014a4bbd9 6. /build/src/Interpreters/ProcessList.cpp:531: DB::QueryStatus::addPipelineExecutor(DB::PipelineExecutor*) @ 0x0000000014a4bd9c 7. /build/src/Processors/Executors/PipelineExecutor.cpp:73: DB::PipelineExecutor::PipelineExecutor(std::shared_ptr, std::allocator>>>&, std::shared_ptr) @ 0x00000000169afe31 8. /build/contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x00000000169c07b5 9. /build/src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x00000000169c0978 10. /build/src/Interpreters/InterpreterKillQueryQuery.cpp:439: DB::InterpreterKillQueryQuery::getSelectResult(String const&, String const&) @ 0x0000000014cf0f04 11. /build/src/Interpreters/InterpreterKillQueryQuery.cpp:222: DB::InterpreterKillQueryQuery::execute() @ 0x0000000014cebde2 12. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88dc9 13. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 14. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 15. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 16. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 17. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 18. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 19. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 20. ? @ 0x00007fbc6213eac3 21. ? @ 0x00007fbc621d0850 2025.07.28 12:02:34.015092 [ 4900 ] {1ff7c7a7-528a-4150-8a55-363c84594dc4} executeQuery: Code: 48. DB::Exception: WITH TOTALS and WITH ROLLUP or CUBE are not supported together in presence of QUALIFY. (NOT_IMPLEMENTED) (version 25.3.6.10636.altinitytest (altinity build)) (from [::1]:36286) (comment: 03095_window_functions_qualify.sql) (query 17, line 34) (in query: SELECT 4, count(4) IGNORE NULLS, number % 2 AS key FROM numbers(10) GROUP BY key WITH ROLLUP WITH TOTALS QUALIFY key = materialize(0);), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000000a074fcb 4. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5480: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000140156ef 5. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000140127f9 6. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000014011fce 7. /build/src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000001406ce8a 8. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000014973b42 9. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000001497268d 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000014974d24 11. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001492924b 12. /build/src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88641 13. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 14. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 15. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 16. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 17. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 18. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 19. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 20. ? @ 0x00007fbc6213eac3 21. ? @ 0x00007fbc621d0850 2025.07.28 12:02:34.019696 [ 4900 ] {} TCPHandler: Code: 48. DB::Exception: WITH TOTALS and WITH ROLLUP or CUBE are not supported together in presence of QUALIFY. (NOT_IMPLEMENTED), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000000a074fcb 4. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5480: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000140156ef 5. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000140127f9 6. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000014011fce 7. /build/src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000001406ce8a 8. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000014973b42 9. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000001497268d 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000014974d24 11. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001492924b 12. /build/src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88641 13. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 14. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 15. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 16. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 17. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 18. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 19. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 20. ? @ 0x00007fbc6213eac3 21. ? @ 0x00007fbc621d0850 2025.07.28 12:02:34.086526 [ 62055 ] {d5936b4e-8ab8-4321-a7d1-8da8e8d0a391} executeQuery: Code: 394. DB::Exception: Query was cancelled. (QUERY_WAS_CANCELLED) (version 25.3.6.10636.altinitytest (altinity build)) (from [::1]:55126) (comment: 02461_cancel_finish_race.sh) (query 1, line 1) (in query: KILL QUERY WHERE current_database = 'test_dtwle8fg' SYNC FORMAT Null), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000000a074fcb 4. /build/src/Interpreters/ProcessList.cpp:567: DB::QueryStatus::throwQueryWasCancelled() const @ 0x0000000014a4bc85 5. /build/src/Interpreters/ProcessList.cpp:520: DB::QueryStatus::throwProperExceptionIfNeeded(unsigned long const&, unsigned long const&) @ 0x0000000014a4bbd9 6. /build/src/Interpreters/ProcessList.cpp:557: DB::QueryStatus::checkTimeLimit() @ 0x0000000014a4c2cd 7. /build/src/Processors/Executors/PipelineExecutor.cpp:206: DB::PipelineExecutor::finalizeExecution() @ 0x00000000169b13ba 8. /build/src/Processors/Executors/PipelineExecutor.cpp:153: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x00000000169b0584 9. /build/src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:se190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169bfeab 10. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc3d92 11. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fcca080 12. ? @ 0x00007fbc6213eac3 13. ? @ 0x00007fbc621d0850 2025.07.28 12:02:34.119938 [ 4900 ] {4a773669-00d5-4060-bdd2-106f9a465f2c} executeQuery: Code: 48. DB::Exception: WITH TOTALS and WITH ROLLUP or CUBE are not supported together in presence of QUALIFY. (NOT_IMPLEMENTED) (version 25.3.6.10636.altinitytest (altinity build)) (from [::1]:36286) (comment: 03095_window_functions_qualify.sql) (query 18, line 36) (in query: SELECT 3, number % toLowCardinality(2) AS key, count() IGNORE NULLS FROM numbers(10) GROUP BY key WITH ROLLUP WITH TOTALS QUALIFY key = 0;), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000000a074fcb 4. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5480: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000140156ef 5. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000140127f9 6. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000014011fce 7. /build/src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000001406ce8a 8. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000014973b42 9. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000001497268d 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000014974d24 11. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001492924b 12. /build/src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88641 13. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 14. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 15. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 16. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 17. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 18. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 19. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 20. ? @ 0x00007fbc6213eac3 21. ? @ 0x00007fbc621d0850 2025.07.28 12:02:34.122002 [ 4900 ] {} TCPHandler: Code: 48. DB::Exception: WITH TOTALS and WITH ROLLUP or CUBE are not supported together in presence of QUALIFY. (NOT_IMPLEMENTED), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000000a074fcb 4. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5480: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000140156ef 5. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000140127f9 6. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000014011fce 7. /build/src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000001406ce8a 8. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000014973b42 9. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000001497268d 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000014974d24 11. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001492924b 12. /build/src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88641 13. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 14. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 15. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 16. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 17. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 18. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 19. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 20. ? @ 0x00007fbc6213eac3 21. ? @ 0x00007fbc621d0850 2025.07.28 12:02:34.157266 [ 62055 ] {} TCPHandler: Code: 394. DB::Exception: Query was cancelled. (QUERY_WAS_CANCELLED), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000000a074fcb 4. /build/src/Interpreters/ProcessList.cpp:567: DB::QueryStatus::throwQueryWasCancelled() const @ 0x0000000014a4bc85 5. /build/src/Interpreters/ProcessList.cpp:520: DB::QueryStatus::throwProperExceptionIfNeeded(unsigned long const&, unsigned long const&) @ 0x0000000014a4bbd9 6. /build/src/Interpreters/ProcessList.cpp:557: DB::QueryStatus::checkTimeLimit() @ 0x0000000014a4c2cd 7. /build/src/Processors/Executors/PipelineExecutor.cpp:206: DB::PipelineExecutor::finalizeExecution() @ 0x00000000169b13ba 8. /build/src/Processors/Executors/PipelineExecutor.cpp:153: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x00000000169b0584 9. /build/src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:se190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169bfeab 10. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc3d92 11. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fcca080 12. ? @ 0x00007fbc6213eac3 13. ? @ 0x00007fbc621d0850 Job's origin stack trace: 0. /build/src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000000fc33b84 1. /build/src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000000fcc2ea7 2. /build/src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fcc535c 3. /build/src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000000fcc584d 4. /build/src/Common/ThreadPool.h:279: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x00000000169bf193 5. /build/src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x00000000169bf518 6. /build/src/Server/TCPHandler.cpp:1237: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x00000000168f1525 7. /build/src/Server/TCPHandler.cpp:678: DB::TCPHandler::runImpl() @ 0x00000000168e68e5 8. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 9. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 10. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 11. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 12. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 13. ? @ 0x00007fbc6213eac3 14. ? @ 0x00007fbc621d0850 2025.07.28 12:02:34.164750 [ 3968 ] {} test_13.rmt2 (7f9b740d-015c-470e-8cc6-8ba33be0dc63): auto DB::StorageReplicatedMergeTree::processQueueEntry(ReplicatedMergeTreeQueue::SelectedEntryPtr)::(anonymous class)::operator()(LogEntryPtr &) const: Code: 86. DB::HTTPException: Received error from remote server http://146b4357c08d:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Ftest%2F01165%2Ftest_13%2Frmt%2Freplicas%2F1&part=20250728_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.6.10636.altinitytest (altinity build)) '. (RECEIVED_ERROR_FROM_REMOTE_IO_SERVER), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.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 const&, int&&, String const&, unsigned long&&, String const&) @ 0x000000000feda8d9 4. /build/src/IO/HTTPCommon.cpp:104: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x000000000feda6e2 5. /build/src/IO/HTTPCommon.cpp:93: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x000000000feda537 6. /build/src/IO/ReadWriteBufferFromHTTP.cpp:277: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x000000001184a4c4 7. /build/src/IO/ReadWriteBufferFromHTTP.cpp:285: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x000000001184a615 8. /build/src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x000000001184ae59 9. /build/src/IO/ReadWriteBufferFromHTTP.cpp:472: void std::__function::__policy_invoker::__call_impl[abi:se190107]>(std::__function::__policy_storage const*) @ 0x000000001184cedd 10. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001184858b 11. /build/src/IO/ReadWriteBufferFromHTTP.cpp:465: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x000000001184bf0b 12. /build/src/IO/ReadBuffer.h:60: DB::ReadBuffer::next() @ 0x000000000a148c7b 13. /build/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) @ 0x0000000011849fb2 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]>&)>&, 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&) @ 0x0000000011841980 15. /build/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) @ 0x000000001621208e 16. /build/src/Storages/StorageReplicatedMergeTree.cpp:5228: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl[abi:se190107] const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000015f9a5fe 17. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000015ed8bfd 18. /build/src/Storages/StorageReplicatedMergeTree.cpp:2514: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x0000000015ec9aab 19. /build/src/Storages/StorageReplicatedMergeTree.cpp:2349: DB::StorageReplicatedMergeTree::executeLogEntry(DB::ReplicatedMergeTreeLogEntry&) @ 0x0000000015eba91b 20. /build/src/Storages/StorageReplicatedMergeTree.cpp:3876: bool std::__function::__policy_invoker&)>::__call_impl[abi:se190107])::$_1, bool (std::shared_ptr&)>>(std::__function::__policy_storage const*, std::shared_ptr&) @ 0x0000000015f9837e 21. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000165d6fc3 22. /build/src/Storages/StorageReplicatedMergeTree.cpp:3872: DB::StorageReplicatedMergeTree::processQueueEntry(std::shared_ptr) @ 0x0000000015efc18a 23. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001624c1b2 24. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000162f9c70 25. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x00000000162fa55a 26. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc6653 27. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000000fccc4c3 28. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc3d92 29. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fcca080 30. ? @ 0x00007fbc6213eac3 31. ? @ 0x00007fbc621d0850 (version 25.3.6.10636.altinitytest (altinity build)) 2025.07.28 12:02:34.184046 [ 63425 ] {} TCPHandler: Code: 394. DB::Exception: Query was cancelled. (QUERY_WAS_CANCELLED), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000000a074fcb 4. /build/src/Interpreters/ProcessList.cpp:567: DB::QueryStatus::throwQueryWasCancelled() const @ 0x0000000014a4bc85 5. /build/src/Interpreters/ProcessList.cpp:520: DB::QueryStatus::throwProperExceptionIfNeeded(unsigned long const&, unsigned long const&) @ 0x0000000014a4bbd9 6. /build/src/Interpreters/ProcessList.cpp:531: DB::QueryStatus::addPipelineExecutor(DB::PipelineExecutor*) @ 0x0000000014a4bd9c 7. /build/src/Processors/Executors/PipelineExecutor.cpp:73: DB::PipelineExecutor::PipelineExecutor(std::shared_ptr, std::allocator>>>&, std::shared_ptr) @ 0x00000000169afe31 8. /build/contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x00000000169c07b5 9. /build/src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x00000000169c0978 10. /build/src/Interpreters/InterpreterKillQueryQuery.cpp:439: DB::InterpreterKillQueryQuery::getSelectResult(String const&, String const&) @ 0x0000000014cf0f04 11. /build/src/Interpreters/InterpreterKillQueryQuery.cpp:222: DB::InterpreterKillQueryQuery::execute() @ 0x0000000014cebde2 12. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88dc9 13. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 14. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 15. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 16. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 17. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 18. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 19. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 20. ? @ 0x00007fbc6213eac3 21. ? @ 0x00007fbc621d0850 2025.07.28 12:02:34.281166 [ 17252 ] {ecde305f-a737-4505-8236-2ce445895eb9} executeQuery: Code: 394. DB::Exception: Query was cancelled. (QUERY_WAS_CANCELLED) (version 25.3.6.10636.altinitytest (altinity build)) (from [::1]:55270) (comment: 02461_cancel_finish_race.sh) (query 1, line 1) (in query: KILL QUERY WHERE current_database = 'test_dtwle8fg' SYNC FORMAT Null), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000000a074fcb 4. /build/src/Interpreters/ProcessList.cpp:567: DB::QueryStatus::throwQueryWasCancelled() const @ 0x0000000014a4bc85 5. /build/src/Interpreters/ProcessList.cpp:520: DB::QueryStatus::throwProperExceptionIfNeeded(unsigned long const&, unsigned long const&) @ 0x0000000014a4bbd9 6. /build/src/Interpreters/ProcessList.cpp:557: DB::QueryStatus::checkTimeLimit() @ 0x0000000014a4c2cd 7. /build/src/Processors/Executors/PipelineExecutor.cpp:206: DB::PipelineExecutor::finalizeExecution() @ 0x00000000169b13ba 8. /build/src/Processors/Executors/PipelineExecutor.cpp:153: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x00000000169b0584 9. /build/src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:se190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169bfeab 10. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc3d92 11. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fcca080 12. ? @ 0x00007fbc6213eac3 13. ? @ 0x00007fbc621d0850 2025.07.28 12:02:34.351715 [ 17252 ] {} TCPHandler: Code: 394. DB::Exception: Query was cancelled. (QUERY_WAS_CANCELLED), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000000a074fcb 4. /build/src/Interpreters/ProcessList.cpp:567: DB::QueryStatus::throwQueryWasCancelled() const @ 0x0000000014a4bc85 5. /build/src/Interpreters/ProcessList.cpp:520: DB::QueryStatus::throwProperExceptionIfNeeded(unsigned long const&, unsigned long const&) @ 0x0000000014a4bbd9 6. /build/src/Interpreters/ProcessList.cpp:557: DB::QueryStatus::checkTimeLimit() @ 0x0000000014a4c2cd 7. /build/src/Processors/Executors/PipelineExecutor.cpp:206: DB::PipelineExecutor::finalizeExecution() @ 0x00000000169b13ba 8. /build/src/Processors/Executors/PipelineExecutor.cpp:153: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x00000000169b0584 9. /build/src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:se190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169bfeab 10. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc3d92 11. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fcca080 12. ? @ 0x00007fbc6213eac3 13. ? @ 0x00007fbc621d0850 Job's origin stack trace: 0. /build/src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000000fc33b84 1. /build/src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000000fcc2ea7 2. /build/src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fcc535c 3. /build/src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000000fcc584d 4. /build/src/Common/ThreadPool.h:279: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x00000000169bf193 5. /build/src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x00000000169bf518 6. /build/src/Server/TCPHandler.cpp:1237: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x00000000168f1525 7. /build/src/Server/TCPHandler.cpp:678: DB::TCPHandler::runImpl() @ 0x00000000168e68e5 8. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 9. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 10. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 11. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 12. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 13. ? @ 0x00007fbc6213eac3 14. ? @ 0x00007fbc621d0850 2025.07.28 12:02:34.380316 [ 11826 ] {} TCPHandler: Code: 394. DB::Exception: Query 'ce8bea28-f3b6-4326-830e-81524390f998' is killed in pending state. (QUERY_WAS_CANCELLED), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x000000000a06b56b 4. /build/src/Interpreters/executeQuery.cpp:1522: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c8a4ef 5. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 6. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 7. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 8. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 9. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 10. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 11. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 12. ? @ 0x00007fbc6213eac3 13. ? @ 0x00007fbc621d0850 2025.07.28 12:02:34.397062 [ 4446 ] {46c68320-1ad9-447b-9861-4d12fbac3710} executeQuery: Code: 394. DB::Exception: Query was cancelled. (QUERY_WAS_CANCELLED) (version 25.3.6.10636.altinitytest (altinity build)) (from [::1]:55260) (comment: 02461_cancel_finish_race.sh) (query 1, line 1) (in query: KILL QUERY WHERE current_database = 'test_dtwle8fg' SYNC FORMAT Null), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000000a074fcb 4. /build/src/Interpreters/ProcessList.cpp:567: DB::QueryStatus::throwQueryWasCancelled() const @ 0x0000000014a4bc85 5. /build/src/Interpreters/ProcessList.cpp:520: DB::QueryStatus::throwProperExceptionIfNeeded(unsigned long const&, unsigned long const&) @ 0x0000000014a4bbd9 6. /build/src/Interpreters/ProcessList.cpp:557: DB::QueryStatus::checkTimeLimit() @ 0x0000000014a4c2cd 7. /build/src/Processors/Executors/PipelineExecutor.cpp:206: DB::PipelineExecutor::finalizeExecution() @ 0x00000000169b13ba 8. /build/src/Processors/Executors/PipelineExecutor.cpp:153: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x00000000169b0584 9. /build/src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:se190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169bfeab 10. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc3d92 11. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fcca080 12. ? @ 0x00007fbc6213eac3 13. ? @ 0x00007fbc621d0850 2025.07.28 12:02:34.407837 [ 17232 ] {3d89ffcd-31c5-414d-ac44-2a8d93e524be} executeQuery: Code: 394. DB::Exception: Query was cancelled. (QUERY_WAS_CANCELLED) (version 25.3.6.10636.altinitytest (altinity build)) (from [::1]:55294) (comment: 02461_cancel_finish_race.sh) (query 1, line 1) (in query: KILL QUERY WHERE current_database = 'test_dtwle8fg' SYNC FORMAT Null), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000000a074fcb 4. /build/src/Interpreters/ProcessList.cpp:567: DB::QueryStatus::throwQueryWasCancelled() const @ 0x0000000014a4bc85 5. /build/src/Interpreters/ProcessList.cpp:520: DB::QueryStatus::throwProperExceptionIfNeeded(unsigned long const&, unsigned long const&) @ 0x0000000014a4bbd9 6. /build/src/Interpreters/ProcessList.cpp:557: DB::QueryStatus::checkTimeLimit() @ 0x0000000014a4c2cd 7. /build/src/Processors/Executors/PipelineExecutor.cpp:206: DB::PipelineExecutor::finalizeExecution() @ 0x00000000169b13ba 8. /build/src/Processors/Executors/PipelineExecutor.cpp:153: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x00000000169b0584 9. /build/src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:se190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169bfeab 10. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc3d92 11. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fcca080 12. ? @ 0x00007fbc6213eac3 13. ? @ 0x00007fbc621d0850 2025.07.28 12:02:34.422427 [ 17232 ] {} TCPHandler: Code: 394. DB::Exception: Query was cancelled. (QUERY_WAS_CANCELLED), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000000a074fcb 4. /build/src/Interpreters/ProcessList.cpp:567: DB::QueryStatus::throwQueryWasCancelled() const @ 0x0000000014a4bc85 5. /build/src/Interpreters/ProcessList.cpp:520: DB::QueryStatus::throwProperExceptionIfNeeded(unsigned long const&, unsigned long const&) @ 0x0000000014a4bbd9 6. /build/src/Interpreters/ProcessList.cpp:557: DB::QueryStatus::checkTimeLimit() @ 0x0000000014a4c2cd 7. /build/src/Processors/Executors/PipelineExecutor.cpp:206: DB::PipelineExecutor::finalizeExecution() @ 0x00000000169b13ba 8. /build/src/Processors/Executors/PipelineExecutor.cpp:153: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x00000000169b0584 9. /build/src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:se190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169bfeab 10. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc3d92 11. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fcca080 12. ? @ 0x00007fbc6213eac3 13. ? @ 0x00007fbc621d0850 Job's origin stack trace: 0. /build/src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000000fc33b84 1. /build/src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000000fcc2ea7 2. /build/src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fcc535c 3. /build/src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000000fcc584d 4. /build/src/Common/ThreadPool.h:279: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x00000000169bf193 5. /build/src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x00000000169bf518 6. /build/src/Server/TCPHandler.cpp:1237: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x00000000168f1525 7. /build/src/Server/TCPHandler.cpp:678: DB::TCPHandler::runImpl() @ 0x00000000168e68e5 8. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 9. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 10. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 11. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 12. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 13. ? @ 0x00007fbc6213eac3 14. ? @ 0x00007fbc621d0850 2025.07.28 12:02:34.481766 [ 4446 ] {} TCPHandler: Code: 394. DB::Exception: Query was cancelled. (QUERY_WAS_CANCELLED), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000000a074fcb 4. /build/src/Interpreters/ProcessList.cpp:567: DB::QueryStatus::throwQueryWasCancelled() const @ 0x0000000014a4bc85 5. /build/src/Interpreters/ProcessList.cpp:520: DB::QueryStatus::throwProperExceptionIfNeeded(unsigned long const&, unsigned long const&) @ 0x0000000014a4bbd9 6. /build/src/Interpreters/ProcessList.cpp:557: DB::QueryStatus::checkTimeLimit() @ 0x0000000014a4c2cd 7. /build/src/Processors/Executors/PipelineExecutor.cpp:206: DB::PipelineExecutor::finalizeExecution() @ 0x00000000169b13ba 8. /build/src/Processors/Executors/PipelineExecutor.cpp:153: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x00000000169b0584 9. /build/src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:se190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169bfeab 10. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc3d92 11. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fcca080 12. ? @ 0x00007fbc6213eac3 13. ? @ 0x00007fbc621d0850 Job's origin stack trace: 0. /build/src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000000fc33b84 1. /build/src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000000fcc2ea7 2. /build/src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fcc535c 3. /build/src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000000fcc584d 4. /build/src/Common/ThreadPool.h:279: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x00000000169bf193 5. /build/src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x00000000169bf518 6. /build/src/Server/TCPHandler.cpp:1237: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x00000000168f1525 7. /build/src/Server/TCPHandler.cpp:678: DB::TCPHandler::runImpl() @ 0x00000000168e68e5 8. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 9. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 10. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 11. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 12. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 13. ? @ 0x00007fbc6213eac3 14. ? @ 0x00007fbc621d0850 2025.07.28 12:02:34.521234 [ 17243 ] {0bdc0808-b4c4-4015-b95a-aea3da95c547} executeQuery: Code: 57. DB::Exception: Table test_15.x already exists. (TABLE_ALREADY_EXISTS) (version 25.3.6.10636.altinitytest (altinity build)) (from [::1]:55438) (comment: 03171_hashed_dictionary_short_circuit_bug_fix.sql) (query 1, line 1) (in query: CREATE TABLE x ( hash_id UInt64, user_result Decimal(3, 2) ) ENGINE = Memory();), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000a06a8eb 4. /build/src/Interpreters/InterpreterCreateQuery.cpp:1824: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x0000000014901d53 5. /build/src/Interpreters/InterpreterCreateQuery.cpp:1743: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000148f9aa9 6. /build/src/Interpreters/InterpreterCreateQuery.cpp:2352: DB::InterpreterCreateQuery::execute() @ 0x0000000014905a41 7. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88dc9 8. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 9. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 10. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 11. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 12. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 13. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 14. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 15. ? @ 0x00007fbc6213eac3 16. ? @ 0x00007fbc621d0850 2025.07.28 12:02:34.540763 [ 17243 ] {} TCPHandler: Code: 57. DB::Exception: Table test_15.x already exists. (TABLE_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000a06a8eb 4. /build/src/Interpreters/InterpreterCreateQuery.cpp:1824: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x0000000014901d53 5. /build/src/Interpreters/InterpreterCreateQuery.cpp:1743: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000148f9aa9 6. /build/src/Interpreters/InterpreterCreateQuery.cpp:2352: DB::InterpreterCreateQuery::execute() @ 0x0000000014905a41 7. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88dc9 8. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 9. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 10. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 11. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 12. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 13. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 14. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 15. ? @ 0x00007fbc6213eac3 16. ? @ 0x00007fbc621d0850 2025.07.28 12:02:34.610029 [ 3976 ] {} test_13.rmt2 (7f9b740d-015c-470e-8cc6-8ba33be0dc63): auto DB::StorageReplicatedMergeTree::processQueueEntry(ReplicatedMergeTreeQueue::SelectedEntryPtr)::(anonymous class)::operator()(LogEntryPtr &) const: Code: 86. DB::HTTPException: Received error from remote server http://146b4357c08d:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Ftest%2F01165%2Ftest_13%2Frmt%2Freplicas%2F1&part=20250728_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.6.10636.altinitytest (altinity build)) '. (RECEIVED_ERROR_FROM_REMOTE_IO_SERVER), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.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 const&, int&&, String const&, unsigned long&&, String const&) @ 0x000000000feda8d9 4. /build/src/IO/HTTPCommon.cpp:104: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x000000000feda6e2 5. /build/src/IO/HTTPCommon.cpp:93: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x000000000feda537 6. /build/src/IO/ReadWriteBufferFromHTTP.cpp:277: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x000000001184a4c4 7. /build/src/IO/ReadWriteBufferFromHTTP.cpp:285: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x000000001184a615 8. /build/src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x000000001184ae59 9. /build/src/IO/ReadWriteBufferFromHTTP.cpp:472: void std::__function::__policy_invoker::__call_impl[abi:se190107]>(std::__function::__policy_storage const*) @ 0x000000001184cedd 10. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001184858b 11. /build/src/IO/ReadWriteBufferFromHTTP.cpp:465: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x000000001184bf0b 12. /build/src/IO/ReadBuffer.h:60: DB::ReadBuffer::next() @ 0x000000000a148c7b 13. /build/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) @ 0x0000000011849fb2 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]>&)>&, 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&) @ 0x0000000011841980 15. /build/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) @ 0x000000001621208e 16. /build/src/Storages/StorageReplicatedMergeTree.cpp:5228: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl[abi:se190107] const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000015f9a5fe 17. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000015ed8bfd 18. /build/src/Storages/StorageReplicatedMergeTree.cpp:2514: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x0000000015ec9aab 19. /build/src/Storages/StorageReplicatedMergeTree.cpp:2349: DB::StorageReplicatedMergeTree::executeLogEntry(DB::ReplicatedMergeTreeLogEntry&) @ 0x0000000015eba91b 20. /build/src/Storages/StorageReplicatedMergeTree.cpp:3876: bool std::__function::__policy_invoker&)>::__call_impl[abi:se190107])::$_1, bool (std::shared_ptr&)>>(std::__function::__policy_storage const*, std::shared_ptr&) @ 0x0000000015f9837e 21. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000165d6fc3 22. /build/src/Storages/StorageReplicatedMergeTree.cpp:3872: DB::StorageReplicatedMergeTree::processQueueEntry(std::shared_ptr) @ 0x0000000015efc18a 23. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001624c1b2 24. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000162f9c70 25. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x00000000162fa55a 26. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc6653 27. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000000fccc4c3 28. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc3d92 29. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fcca080 30. ? @ 0x00007fbc6213eac3 31. ? @ 0x00007fbc621d0850 (version 25.3.6.10636.altinitytest (altinity build)) 2025.07.28 12:02:34.628695 [ 17255 ] {} TCPHandler: Code: 394. DB::Exception: Query '640043c5-65dc-41a2-b4d8-d19de1ae5deb' is killed in pending state. (QUERY_WAS_CANCELLED), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x000000000a06b56b 4. /build/src/Interpreters/executeQuery.cpp:1522: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c8a4ef 5. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 6. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 7. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 8. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 9. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 10. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 11. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 12. ? @ 0x00007fbc6213eac3 13. ? @ 0x00007fbc621d0850 2025.07.28 12:02:34.641913 [ 62056 ] {} TCPHandler: Code: 394. DB::Exception: Query was cancelled. (QUERY_WAS_CANCELLED), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000000a074fcb 4. /build/src/Interpreters/ProcessList.cpp:567: DB::QueryStatus::throwQueryWasCancelled() const @ 0x0000000014a4bc85 5. /build/src/Interpreters/ProcessList.cpp:520: DB::QueryStatus::throwProperExceptionIfNeeded(unsigned long const&, unsigned long const&) @ 0x0000000014a4bbd9 6. /build/src/Interpreters/ProcessList.cpp:531: DB::QueryStatus::addPipelineExecutor(DB::PipelineExecutor*) @ 0x0000000014a4bd9c 7. /build/src/Processors/Executors/PipelineExecutor.cpp:73: DB::PipelineExecutor::PipelineExecutor(std::shared_ptr, std::allocator>>>&, std::shared_ptr) @ 0x00000000169afe31 8. /build/contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x00000000169c07b5 9. /build/src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x00000000169c0978 10. /build/src/Interpreters/InterpreterKillQueryQuery.cpp:439: DB::InterpreterKillQueryQuery::getSelectResult(String const&, String const&) @ 0x0000000014cf0f04 11. /build/src/Interpreters/InterpreterKillQueryQuery.cpp:222: DB::InterpreterKillQueryQuery::execute() @ 0x0000000014cebde2 12. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88dc9 13. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 14. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 15. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 16. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 17. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 18. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 19. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 20. ? @ 0x00007fbc6213eac3 21. ? @ 0x00007fbc621d0850 2025.07.28 12:02:34.787238 [ 62075 ] {a530797d-9360-4b00-bdd2-6cbbfedecf11} executeQuery: Code: 394. DB::Exception: Query was cancelled. (QUERY_WAS_CANCELLED) (version 25.3.6.10636.altinitytest (altinity build)) (from [::1]:55420) (comment: 02461_cancel_finish_race.sh) (query 1, line 1) (in query: KILL QUERY WHERE current_database = 'test_dtwle8fg' SYNC FORMAT Null), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000000a074fcb 4. /build/src/Interpreters/ProcessList.cpp:567: DB::QueryStatus::throwQueryWasCancelled() const @ 0x0000000014a4bc85 5. /build/src/Interpreters/ProcessList.cpp:520: DB::QueryStatus::throwProperExceptionIfNeeded(unsigned long const&, unsigned long const&) @ 0x0000000014a4bbd9 6. /build/src/Interpreters/ProcessList.cpp:557: DB::QueryStatus::checkTimeLimit() @ 0x0000000014a4c2cd 7. /build/src/Processors/Executors/PipelineExecutor.cpp:206: DB::PipelineExecutor::finalizeExecution() @ 0x00000000169b13ba 8. /build/src/Processors/Executors/PipelineExecutor.cpp:153: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x00000000169b0584 9. /build/src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:se190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169bfeab 10. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc3d92 11. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fcca080 12. ? @ 0x00007fbc6213eac3 13. ? @ 0x00007fbc621d0850 2025.07.28 12:02:34.804175 [ 62075 ] {} TCPHandler: Code: 394. DB::Exception: Query was cancelled. (QUERY_WAS_CANCELLED), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000000a074fcb 4. /build/src/Interpreters/ProcessList.cpp:567: DB::QueryStatus::throwQueryWasCancelled() const @ 0x0000000014a4bc85 5. /build/src/Interpreters/ProcessList.cpp:520: DB::QueryStatus::throwProperExceptionIfNeeded(unsigned long const&, unsigned long const&) @ 0x0000000014a4bbd9 6. /build/src/Interpreters/ProcessList.cpp:557: DB::QueryStatus::checkTimeLimit() @ 0x0000000014a4c2cd 7. /build/src/Processors/Executors/PipelineExecutor.cpp:206: DB::PipelineExecutor::finalizeExecution() @ 0x00000000169b13ba 8. /build/src/Processors/Executors/PipelineExecutor.cpp:153: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x00000000169b0584 9. /build/src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:se190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169bfeab 10. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc3d92 11. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fcca080 12. ? @ 0x00007fbc6213eac3 13. ? @ 0x00007fbc621d0850 Job's origin stack trace: 0. /build/src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000000fc33b84 1. /build/src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000000fcc2ea7 2. /build/src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fcc535c 3. /build/src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000000fcc584d 4. /build/src/Common/ThreadPool.h:279: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x00000000169bf193 5. /build/src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x00000000169bf518 6. /build/src/Server/TCPHandler.cpp:1237: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x00000000168f1525 7. /build/src/Server/TCPHandler.cpp:678: DB::TCPHandler::runImpl() @ 0x00000000168e68e5 8. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 9. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 10. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 11. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 12. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 13. ? @ 0x00007fbc6213eac3 14. ? @ 0x00007fbc621d0850 2025.07.28 12:02:34.829495 [ 17203 ] {0f3a9578-6d82-474d-9b9f-092e207e4d80} executeQuery: Code: 394. DB::Exception: Query was cancelled. (QUERY_WAS_CANCELLED) (version 25.3.6.10636.altinitytest (altinity build)) (from [::1]:55470) (comment: 02461_cancel_finish_race.sh) (query 1, line 1) (in query: KILL QUERY WHERE current_database = 'test_dtwle8fg' SYNC FORMAT Null), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000000a074fcb 4. /build/src/Interpreters/ProcessList.cpp:567: DB::QueryStatus::throwQueryWasCancelled() const @ 0x0000000014a4bc85 5. /build/src/Interpreters/ProcessList.cpp:520: DB::QueryStatus::throwProperExceptionIfNeeded(unsigned long const&, unsigned long const&) @ 0x0000000014a4bbd9 6. /build/src/Interpreters/ProcessList.cpp:557: DB::QueryStatus::checkTimeLimit() @ 0x0000000014a4c2cd 7. /build/src/Processors/Executors/PipelineExecutor.cpp:206: DB::PipelineExecutor::finalizeExecution() @ 0x00000000169b13ba 8. /build/src/Processors/Executors/PipelineExecutor.cpp:153: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x00000000169b0584 9. /build/src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:se190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169bfeab 10. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc3d92 11. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fcca080 12. ? @ 0x00007fbc6213eac3 13. ? @ 0x00007fbc621d0850 2025.07.28 12:02:34.841752 [ 17203 ] {} TCPHandler: Code: 394. DB::Exception: Query was cancelled. (QUERY_WAS_CANCELLED), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000000a074fcb 4. /build/src/Interpreters/ProcessList.cpp:567: DB::QueryStatus::throwQueryWasCancelled() const @ 0x0000000014a4bc85 5. /build/src/Interpreters/ProcessList.cpp:520: DB::QueryStatus::throwProperExceptionIfNeeded(unsigned long const&, unsigned long const&) @ 0x0000000014a4bbd9 6. /build/src/Interpreters/ProcessList.cpp:557: DB::QueryStatus::checkTimeLimit() @ 0x0000000014a4c2cd 7. /build/src/Processors/Executors/PipelineExecutor.cpp:206: DB::PipelineExecutor::finalizeExecution() @ 0x00000000169b13ba 8. /build/src/Processors/Executors/PipelineExecutor.cpp:153: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x00000000169b0584 9. /build/src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:se190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169bfeab 10. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc3d92 11. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fcca080 12. ? @ 0x00007fbc6213eac3 13. ? @ 0x00007fbc621d0850 Job's origin stack trace: 0. /build/src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000000fc33b84 1. /build/src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000000fcc2ea7 2. /build/src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fcc535c 3. /build/src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000000fcc584d 4. /build/src/Common/ThreadPool.h:279: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x00000000169bf193 5. /build/src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x00000000169bf518 6. /build/src/Server/TCPHandler.cpp:1237: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x00000000168f1525 7. /build/src/Server/TCPHandler.cpp:678: DB::TCPHandler::runImpl() @ 0x00000000168e68e5 8. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 9. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 10. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 11. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 12. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 13. ? @ 0x00007fbc6213eac3 14. ? @ 0x00007fbc621d0850 2025.07.28 12:02:34.874188 [ 17611 ] {394eb51e-653c-4ecd-85f7-8eba85d28afb} executeQuery: Code: 394. DB::Exception: Query was cancelled. (QUERY_WAS_CANCELLED) (version 25.3.6.10636.altinitytest (altinity build)) (from [::1]:55494) (comment: 02461_cancel_finish_race.sh) (query 1, line 1) (in query: KILL QUERY WHERE current_database = 'test_dtwle8fg' SYNC FORMAT Null), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000000a074fcb 4. /build/src/Interpreters/ProcessList.cpp:567: DB::QueryStatus::throwQueryWasCancelled() const @ 0x0000000014a4bc85 5. /build/src/Interpreters/ProcessList.cpp:520: DB::QueryStatus::throwProperExceptionIfNeeded(unsigned long const&, unsigned long const&) @ 0x0000000014a4bbd9 6. /build/src/Interpreters/ProcessList.cpp:557: DB::QueryStatus::checkTimeLimit() @ 0x0000000014a4c2cd 7. /build/src/Processors/Executors/PipelineExecutor.cpp:206: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x00000000169b03a3 8. /build/src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:se190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169bfeab 9. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc3d92 10. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fcca080 11. ? @ 0x00007fbc6213eac3 12. ? @ 0x00007fbc621d0850 2025.07.28 12:02:34.878628 [ 62314 ] {fae780a4-e64b-4f8c-9554-fd11e5a3795d} executeQuery: Code: 394. DB::Exception: Query was cancelled. (QUERY_WAS_CANCELLED) (version 25.3.6.10636.altinitytest (altinity build)) (from [::1]:55426) (comment: 02461_cancel_finish_race.sh) (query 1, line 1) (in query: KILL QUERY WHERE current_database = 'test_dtwle8fg' SYNC FORMAT Null), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000000a074fcb 4. /build/src/Interpreters/ProcessList.cpp:567: DB::QueryStatus::throwQueryWasCancelled() const @ 0x0000000014a4bc85 5. /build/src/Interpreters/ProcessList.cpp:520: DB::QueryStatus::throwProperExceptionIfNeeded(unsigned long const&, unsigned long const&) @ 0x0000000014a4bbd9 6. /build/src/Interpreters/ProcessList.cpp:557: DB::QueryStatus::checkTimeLimit() @ 0x0000000014a4c2cd 7. /build/src/Processors/Executors/PipelineExecutor.cpp:206: DB::PipelineExecutor::finalizeExecution() @ 0x00000000169b13ba 8. /build/src/Processors/Executors/PipelineExecutor.cpp:153: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x00000000169b0584 9. /build/src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:se190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169bfeab 10. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc3d92 11. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fcca080 12. ? @ 0x00007fbc6213eac3 13. ? @ 0x00007fbc621d0850 2025.07.28 12:02:34.900472 [ 62314 ] {} TCPHandler: Code: 394. DB::Exception: Query was cancelled. (QUERY_WAS_CANCELLED), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000000a074fcb 4. /build/src/Interpreters/ProcessList.cpp:567: DB::QueryStatus::throwQueryWasCancelled() const @ 0x0000000014a4bc85 5. /build/src/Interpreters/ProcessList.cpp:520: DB::QueryStatus::throwProperExceptionIfNeeded(unsigned long const&, unsigned long const&) @ 0x0000000014a4bbd9 6. /build/src/Interpreters/ProcessList.cpp:557: DB::QueryStatus::checkTimeLimit() @ 0x0000000014a4c2cd 7. /build/src/Processors/Executors/PipelineExecutor.cpp:206: DB::PipelineExecutor::finalizeExecution() @ 0x00000000169b13ba 8. /build/src/Processors/Executors/PipelineExecutor.cpp:153: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x00000000169b0584 9. /build/src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:se190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169bfeab 10. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc3d92 11. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fcca080 12. ? @ 0x00007fbc6213eac3 13. ? @ 0x00007fbc621d0850 Job's origin stack trace: 0. /build/src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000000fc33b84 1. /build/src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000000fcc2ea7 2. /build/src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fcc535c 3. /build/src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000000fcc584d 4. /build/src/Common/ThreadPool.h:279: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x00000000169bf193 5. /build/src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x00000000169bf518 6. /build/src/Server/TCPHandler.cpp:1237: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x00000000168f1525 7. /build/src/Server/TCPHandler.cpp:678: DB::TCPHandler::runImpl() @ 0x00000000168e68e5 8. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 9. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 10. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 11. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 12. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 13. ? @ 0x00007fbc6213eac3 14. ? @ 0x00007fbc621d0850 2025.07.28 12:02:34.905967 [ 17611 ] {} TCPHandler: Code: 394. DB::Exception: Query was cancelled. (QUERY_WAS_CANCELLED), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000000a074fcb 4. /build/src/Interpreters/ProcessList.cpp:567: DB::QueryStatus::throwQueryWasCancelled() const @ 0x0000000014a4bc85 5. /build/src/Interpreters/ProcessList.cpp:520: DB::QueryStatus::throwProperExceptionIfNeeded(unsigned long const&, unsigned long const&) @ 0x0000000014a4bbd9 6. /build/src/Interpreters/ProcessList.cpp:557: DB::QueryStatus::checkTimeLimit() @ 0x0000000014a4c2cd 7. /build/src/Processors/Executors/PipelineExecutor.cpp:206: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x00000000169b03a3 8. /build/src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:se190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169bfeab 9. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc3d92 10. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fcca080 11. ? @ 0x00007fbc6213eac3 12. ? @ 0x00007fbc621d0850 Job's origin stack trace: 0. /build/src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000000fc33b84 1. /build/src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000000fcc2ea7 2. /build/src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fcc535c 3. /build/src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000000fcc584d 4. /build/src/Common/ThreadPool.h:279: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x00000000169bf193 5. /build/src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x00000000169bf518 6. /build/src/Server/TCPHandler.cpp:1237: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x00000000168f1525 7. /build/src/Server/TCPHandler.cpp:678: DB::TCPHandler::runImpl() @ 0x00000000168e68e5 8. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 9. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 10. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 11. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 12. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 13. ? @ 0x00007fbc6213eac3 14. ? @ 0x00007fbc621d0850 2025.07.28 12:02:35.239327 [ 63425 ] {} TCPHandler: Code: 394. DB::Exception: Query was cancelled. (QUERY_WAS_CANCELLED), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000000a074fcb 4. /build/src/Interpreters/ProcessList.cpp:567: DB::QueryStatus::throwQueryWasCancelled() const @ 0x0000000014a4bc85 5. /build/src/Interpreters/ProcessList.cpp:520: DB::QueryStatus::throwProperExceptionIfNeeded(unsigned long const&, unsigned long const&) @ 0x0000000014a4bbd9 6. /build/src/Interpreters/ProcessList.cpp:557: DB::QueryStatus::checkTimeLimit() @ 0x0000000014a4c2cd 7. /build/src/Processors/Executors/PipelineExecutor.cpp:206: DB::PipelineExecutor::finalizeExecution() @ 0x00000000169b13ba 8. /build/src/Processors/Executors/PipelineExecutor.cpp:181: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x00000000169b1726 9. /build/src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x00000000169c081c 10. /build/src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x00000000169c0978 11. /build/src/Interpreters/InterpreterKillQueryQuery.cpp:439: DB::InterpreterKillQueryQuery::getSelectResult(String const&, String const&) @ 0x0000000014cf0f04 12. /build/src/Interpreters/InterpreterKillQueryQuery.cpp:222: DB::InterpreterKillQueryQuery::execute() @ 0x0000000014cebde2 13. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88dc9 14. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 15. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 16. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 17. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 18. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 19. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 20. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 21. ? @ 0x00007fbc6213eac3 22. ? @ 0x00007fbc621d0850 2025.07.28 12:02:35.251753 [ 62058 ] {ebab074a-83af-45ca-90b0-3bfe1c9b99bb} executeQuery: Code: 394. DB::Exception: Query was cancelled. (QUERY_WAS_CANCELLED) (version 25.3.6.10636.altinitytest (altinity build)) (from [::1]:55520) (comment: 02461_cancel_finish_race.sh) (query 1, line 1) (in query: KILL QUERY WHERE current_database = 'test_dtwle8fg' SYNC FORMAT Null), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000000a074fcb 4. /build/src/Interpreters/ProcessList.cpp:567: DB::QueryStatus::throwQueryWasCancelled() const @ 0x0000000014a4bc85 5. /build/src/Interpreters/ProcessList.cpp:520: DB::QueryStatus::throwProperExceptionIfNeeded(unsigned long const&, unsigned long const&) @ 0x0000000014a4bbd9 6. /build/src/Interpreters/ProcessList.cpp:557: DB::QueryStatus::checkTimeLimit() @ 0x0000000014a4c2cd 7. /build/src/Processors/Executors/PipelineExecutor.cpp:206: DB::PipelineExecutor::finalizeExecution() @ 0x00000000169b13ba 8. /build/src/Processors/Executors/PipelineExecutor.cpp:153: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x00000000169b0584 9. /build/src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:se190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169bfeab 10. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc3d92 11. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fcca080 12. ? @ 0x00007fbc6213eac3 13. ? @ 0x00007fbc621d0850 2025.07.28 12:02:35.255331 [ 62058 ] {} TCPHandler: Code: 394. DB::Exception: Query was cancelled. (QUERY_WAS_CANCELLED), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000000a074fcb 4. /build/src/Interpreters/ProcessList.cpp:567: DB::QueryStatus::throwQueryWasCancelled() const @ 0x0000000014a4bc85 5. /build/src/Interpreters/ProcessList.cpp:520: DB::QueryStatus::throwProperExceptionIfNeeded(unsigned long const&, unsigned long const&) @ 0x0000000014a4bbd9 6. /build/src/Interpreters/ProcessList.cpp:557: DB::QueryStatus::checkTimeLimit() @ 0x0000000014a4c2cd 7. /build/src/Processors/Executors/PipelineExecutor.cpp:206: DB::PipelineExecutor::finalizeExecution() @ 0x00000000169b13ba 8. /build/src/Processors/Executors/PipelineExecutor.cpp:153: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x00000000169b0584 9. /build/src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:se190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169bfeab 10. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc3d92 11. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fcca080 12. ? @ 0x00007fbc6213eac3 13. ? @ 0x00007fbc621d0850 Job's origin stack trace: 0. /build/src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000000fc33b84 1. /build/src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000000fcc2ea7 2. /build/src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fcc535c 3. /build/src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000000fcc584d 4. /build/src/Common/ThreadPool.h:279: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x00000000169bf193 5. /build/src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x00000000169bf518 6. /build/src/Server/TCPHandler.cpp:1237: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x00000000168f1525 7. /build/src/Server/TCPHandler.cpp:678: DB::TCPHandler::runImpl() @ 0x00000000168e68e5 8. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 9. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 10. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 11. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 12. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 13. ? @ 0x00007fbc6213eac3 14. ? @ 0x00007fbc621d0850 2025.07.28 12:02:35.268005 [ 62093 ] {9a54bf13-44fd-471b-b2cd-8dd4587a736a} executeQuery: Code: 394. DB::Exception: Query was cancelled. (QUERY_WAS_CANCELLED) (version 25.3.6.10636.altinitytest (altinity build)) (from [::1]:55596) (comment: 02461_cancel_finish_race.sh) (query 1, line 1) (in query: KILL QUERY WHERE current_database = 'test_dtwle8fg' SYNC FORMAT Null), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000000a074fcb 4. /build/src/Interpreters/ProcessList.cpp:567: DB::QueryStatus::throwQueryWasCancelled() const @ 0x0000000014a4bc85 5. /build/src/Interpreters/ProcessList.cpp:520: DB::QueryStatus::throwProperExceptionIfNeeded(unsigned long const&, unsigned long const&) @ 0x0000000014a4bbd9 6. /build/src/Interpreters/ProcessList.cpp:557: DB::QueryStatus::checkTimeLimit() @ 0x0000000014a4c2cd 7. /build/src/Processors/Executors/PipelineExecutor.cpp:206: DB::PipelineExecutor::finalizeExecution() @ 0x00000000169b13ba 8. /build/src/Processors/Executors/PipelineExecutor.cpp:153: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x00000000169b0584 9. /build/src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:se190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169bfeab 10. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc3d92 11. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fcca080 12. ? @ 0x00007fbc6213eac3 13. ? @ 0x00007fbc621d0850 2025.07.28 12:02:35.275251 [ 62056 ] {166f77ae-bbf8-4c4b-8025-aaed5d18ae05} executeQuery: Code: 394. DB::Exception: Query was cancelled. (QUERY_WAS_CANCELLED) (version 25.3.6.10636.altinitytest (altinity build)) (from [::1]:55580) (comment: 02461_cancel_finish_race.sh) (query 1, line 1) (in query: KILL QUERY WHERE current_database = 'test_dtwle8fg' SYNC FORMAT Null), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000000a074fcb 4. /build/src/Interpreters/ProcessList.cpp:567: DB::QueryStatus::throwQueryWasCancelled() const @ 0x0000000014a4bc85 5. /build/src/Interpreters/ProcessList.cpp:520: DB::QueryStatus::throwProperExceptionIfNeeded(unsigned long const&, unsigned long const&) @ 0x0000000014a4bbd9 6. /build/src/Interpreters/ProcessList.cpp:557: DB::QueryStatus::checkTimeLimit() @ 0x0000000014a4c2cd 7. /build/src/Processors/Executors/PipelineExecutor.cpp:206: DB::PipelineExecutor::finalizeExecution() @ 0x00000000169b13ba 8. /build/src/Processors/Executors/PipelineExecutor.cpp:153: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x00000000169b0584 9. /build/src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:se190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169bfeab 10. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc3d92 11. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fcca080 12. ? @ 0x00007fbc6213eac3 13. ? @ 0x00007fbc621d0850 2025.07.28 12:02:35.291588 [ 62093 ] {} TCPHandler: Code: 394. DB::Exception: Query was cancelled. (QUERY_WAS_CANCELLED), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000000a074fcb 4. /build/src/Interpreters/ProcessList.cpp:567: DB::QueryStatus::throwQueryWasCancelled() const @ 0x0000000014a4bc85 5. /build/src/Interpreters/ProcessList.cpp:520: DB::QueryStatus::throwProperExceptionIfNeeded(unsigned long const&, unsigned long const&) @ 0x0000000014a4bbd9 6. /build/src/Interpreters/ProcessList.cpp:557: DB::QueryStatus::checkTimeLimit() @ 0x0000000014a4c2cd 7. /build/src/Processors/Executors/PipelineExecutor.cpp:206: DB::PipelineExecutor::finalizeExecution() @ 0x00000000169b13ba 8. /build/src/Processors/Executors/PipelineExecutor.cpp:153: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x00000000169b0584 9. /build/src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:se190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169bfeab 10. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc3d92 11. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fcca080 12. ? @ 0x00007fbc6213eac3 13. ? @ 0x00007fbc621d0850 Job's origin stack trace: 0. /build/src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000000fc33b84 1. /build/src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000000fcc2ea7 2. /build/src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fcc535c 3. /build/src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000000fcc584d 4. /build/src/Common/ThreadPool.h:279: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x00000000169bf193 5. /build/src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x00000000169bf518 6. /build/src/Server/TCPHandler.cpp:1237: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x00000000168f1525 7. /build/src/Server/TCPHandler.cpp:678: DB::TCPHandler::runImpl() @ 0x00000000168e68e5 8. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 9. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 10. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 11. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 12. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 13. ? @ 0x00007fbc6213eac3 14. ? @ 0x00007fbc621d0850 2025.07.28 12:02:35.293387 [ 62056 ] {} TCPHandler: Code: 394. DB::Exception: Query was cancelled. (QUERY_WAS_CANCELLED), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000000a074fcb 4. /build/src/Interpreters/ProcessList.cpp:567: DB::QueryStatus::throwQueryWasCancelled() const @ 0x0000000014a4bc85 5. /build/src/Interpreters/ProcessList.cpp:520: DB::QueryStatus::throwProperExceptionIfNeeded(unsigned long const&, unsigned long const&) @ 0x0000000014a4bbd9 6. /build/src/Interpreters/ProcessList.cpp:557: DB::QueryStatus::checkTimeLimit() @ 0x0000000014a4c2cd 7. /build/src/Processors/Executors/PipelineExecutor.cpp:206: DB::PipelineExecutor::finalizeExecution() @ 0x00000000169b13ba 8. /build/src/Processors/Executors/PipelineExecutor.cpp:153: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x00000000169b0584 9. /build/src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:se190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169bfeab 10. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc3d92 11. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fcca080 12. ? @ 0x00007fbc6213eac3 13. ? @ 0x00007fbc621d0850 Job's origin stack trace: 0. /build/src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000000fc33b84 1. /build/src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000000fcc2ea7 2. /build/src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fcc535c 3. /build/src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000000fcc584d 4. /build/src/Common/ThreadPool.h:279: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x00000000169bf193 5. /build/src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x00000000169bf518 6. /build/src/Server/TCPHandler.cpp:1237: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x00000000168f1525 7. /build/src/Server/TCPHandler.cpp:678: DB::TCPHandler::runImpl() @ 0x00000000168e68e5 8. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 9. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 10. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 11. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 12. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 13. ? @ 0x00007fbc6213eac3 14. ? @ 0x00007fbc621d0850 2025.07.28 12:02:35.342051 [ 17611 ] {9d870dce-6a4a-4bf2-a7e5-8c9da8358f82} executeQuery: Code: 394. DB::Exception: Query was cancelled. (QUERY_WAS_CANCELLED) (version 25.3.6.10636.altinitytest (altinity build)) (from [::1]:55658) (comment: 02461_cancel_finish_race.sh) (query 1, line 1) (in query: KILL QUERY WHERE current_database = 'test_dtwle8fg' SYNC FORMAT Null), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000000a074fcb 4. /build/src/Interpreters/ProcessList.cpp:567: DB::QueryStatus::throwQueryWasCancelled() const @ 0x0000000014a4bc85 5. /build/src/Interpreters/ProcessList.cpp:520: DB::QueryStatus::throwProperExceptionIfNeeded(unsigned long const&, unsigned long const&) @ 0x0000000014a4bbd9 6. /build/src/Interpreters/ProcessList.cpp:557: DB::QueryStatus::checkTimeLimit() @ 0x0000000014a4c2cd 7. /build/src/Processors/Executors/PipelineExecutor.cpp:206: DB::PipelineExecutor::finalizeExecution() @ 0x00000000169b13ba 8. /build/src/Processors/Executors/PipelineExecutor.cpp:153: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x00000000169b0584 9. /build/src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:se190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169bfeab 10. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc3d92 11. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fcca080 12. ? @ 0x00007fbc6213eac3 13. ? @ 0x00007fbc621d0850 2025.07.28 12:02:35.362284 [ 62103 ] {80f119ec-1246-4c7d-a022-58227cb02d8b} executeQuery: Code: 394. DB::Exception: Query was cancelled. (QUERY_WAS_CANCELLED) (version 25.3.6.10636.altinitytest (altinity build)) (from [::1]:55664) (comment: 02461_cancel_finish_race.sh) (query 1, line 1) (in query: KILL QUERY WHERE current_database = 'test_dtwle8fg' SYNC FORMAT Null), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000000a074fcb 4. /build/src/Interpreters/ProcessList.cpp:567: DB::QueryStatus::throwQueryWasCancelled() const @ 0x0000000014a4bc85 5. /build/src/Interpreters/ProcessList.cpp:520: DB::QueryStatus::throwProperExceptionIfNeeded(unsigned long const&, unsigned long const&) @ 0x0000000014a4bbd9 6. /build/src/Interpreters/ProcessList.cpp:557: DB::QueryStatus::checkTimeLimit() @ 0x0000000014a4c2cd 7. /build/src/Processors/Executors/PipelineExecutor.cpp:206: DB::PipelineExecutor::finalizeExecution() @ 0x00000000169b13ba 8. /build/src/Processors/Executors/PipelineExecutor.cpp:153: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x00000000169b0584 9. /build/src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:se190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169bfeab 10. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc3d92 11. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fcca080 12. ? @ 0x00007fbc6213eac3 13. ? @ 0x00007fbc621d0850 2025.07.28 12:02:35.364228 [ 62055 ] {31ffeded-d2f9-440a-aae3-134cba7f8ad8} executeQuery: Code: 394. DB::Exception: Query was cancelled. (QUERY_WAS_CANCELLED) (version 25.3.6.10636.altinitytest (altinity build)) (from [::1]:55688) (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. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000000a074fcb 4. /build/src/Interpreters/ProcessList.cpp:567: DB::QueryStatus::throwQueryWasCancelled() const @ 0x0000000014a4bc85 5. /build/src/Interpreters/ProcessList.cpp:520: DB::QueryStatus::throwProperExceptionIfNeeded(unsigned long const&, unsigned long const&) @ 0x0000000014a4bbd9 6. /build/src/Interpreters/ProcessList.cpp:557: DB::QueryStatus::checkTimeLimit() @ 0x0000000014a4c2cd 7. /build/src/Processors/Executors/PipelineExecutor.cpp:206: DB::PipelineExecutor::finalizeExecution() @ 0x00000000169b13ba 8. /build/src/Processors/Executors/PipelineExecutor.cpp:153: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x00000000169b0584 9. /build/src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:se190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169bfeab 10. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc3d92 11. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fcca080 12. ? @ 0x00007fbc6213eac3 13. ? @ 0x00007fbc621d0850 2025.07.28 12:02:35.387612 [ 62055 ] {} TCPHandler: Code: 394. DB::Exception: Query was cancelled. (QUERY_WAS_CANCELLED), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000000a074fcb 4. /build/src/Interpreters/ProcessList.cpp:567: DB::QueryStatus::throwQueryWasCancelled() const @ 0x0000000014a4bc85 5. /build/src/Interpreters/ProcessList.cpp:520: DB::QueryStatus::throwProperExceptionIfNeeded(unsigned long const&, unsigned long const&) @ 0x0000000014a4bbd9 6. /build/src/Interpreters/ProcessList.cpp:557: DB::QueryStatus::checkTimeLimit() @ 0x0000000014a4c2cd 7. /build/src/Processors/Executors/PipelineExecutor.cpp:206: DB::PipelineExecutor::finalizeExecution() @ 0x00000000169b13ba 8. /build/src/Processors/Executors/PipelineExecutor.cpp:153: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x00000000169b0584 9. /build/src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:se190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169bfeab 10. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc3d92 11. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fcca080 12. ? @ 0x00007fbc6213eac3 13. ? @ 0x00007fbc621d0850 Job's origin stack trace: 0. /build/src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000000fc33b84 1. /build/src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000000fcc2ea7 2. /build/src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fcc535c 3. /build/src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000000fcc584d 4. /build/src/Common/ThreadPool.h:279: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x00000000169bf193 5. /build/src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x00000000169bf518 6. /build/src/Server/TCPHandler.cpp:1237: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x00000000168f1525 7. /build/src/Server/TCPHandler.cpp:678: DB::TCPHandler::runImpl() @ 0x00000000168e68e5 8. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 9. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 10. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 11. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 12. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 13. ? @ 0x00007fbc6213eac3 14. ? @ 0x00007fbc621d0850 2025.07.28 12:02:35.388954 [ 62103 ] {} TCPHandler: Code: 394. DB::Exception: Query was cancelled. (QUERY_WAS_CANCELLED), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000000a074fcb 4. /build/src/Interpreters/ProcessList.cpp:567: DB::QueryStatus::throwQueryWasCancelled() const @ 0x0000000014a4bc85 5. /build/src/Interpreters/ProcessList.cpp:520: DB::QueryStatus::throwProperExceptionIfNeeded(unsigned long const&, unsigned long const&) @ 0x0000000014a4bbd9 6. /build/src/Interpreters/ProcessList.cpp:557: DB::QueryStatus::checkTimeLimit() @ 0x0000000014a4c2cd 7. /build/src/Processors/Executors/PipelineExecutor.cpp:206: DB::PipelineExecutor::finalizeExecution() @ 0x00000000169b13ba 8. /build/src/Processors/Executors/PipelineExecutor.cpp:153: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x00000000169b0584 9. /build/src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:se190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169bfeab 10. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc3d92 11. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fcca080 12. ? @ 0x00007fbc6213eac3 13. ? @ 0x00007fbc621d0850 Job's origin stack trace: 0. /build/src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000000fc33b84 1. /build/src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000000fcc2ea7 2. /build/src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fcc535c 3. /build/src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000000fcc584d 4. /build/src/Common/ThreadPool.h:279: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x00000000169bf193 5. /build/src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x00000000169bf518 6. /build/src/Server/TCPHandler.cpp:1237: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x00000000168f1525 7. /build/src/Server/TCPHandler.cpp:678: DB::TCPHandler::runImpl() @ 0x00000000168e68e5 8. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 9. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 10. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 11. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 12. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 13. ? @ 0x00007fbc6213eac3 14. ? @ 0x00007fbc621d0850 2025.07.28 12:02:35.415711 [ 17203 ] {} TCPHandler: Code: 394. DB::Exception: Query was cancelled. (QUERY_WAS_CANCELLED), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000000a074fcb 4. /build/src/Interpreters/ProcessList.cpp:567: DB::QueryStatus::throwQueryWasCancelled() const @ 0x0000000014a4bc85 5. /build/src/Interpreters/ProcessList.cpp:520: DB::QueryStatus::throwProperExceptionIfNeeded(unsigned long const&, unsigned long const&) @ 0x0000000014a4bbd9 6. /build/src/Interpreters/ProcessList.cpp:531: DB::QueryStatus::addPipelineExecutor(DB::PipelineExecutor*) @ 0x0000000014a4bd9c 7. /build/src/Processors/Executors/PipelineExecutor.cpp:73: DB::PipelineExecutor::PipelineExecutor(std::shared_ptr, std::allocator>>>&, std::shared_ptr) @ 0x00000000169afe31 8. /build/contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x00000000169c07b5 9. /build/src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x00000000169c0978 10. /build/src/Interpreters/InterpreterKillQueryQuery.cpp:439: DB::InterpreterKillQueryQuery::getSelectResult(String const&, String const&) @ 0x0000000014cf0f04 11. /build/src/Interpreters/InterpreterKillQueryQuery.cpp:222: DB::InterpreterKillQueryQuery::execute() @ 0x0000000014cebde2 12. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88dc9 13. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 14. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 15. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 16. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 17. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 18. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 19. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 20. ? @ 0x00007fbc6213eac3 21. ? @ 0x00007fbc621d0850 2025.07.28 12:02:35.433710 [ 17252 ] {de63dd7d-cfce-4ae8-973f-f108b147f209} executeQuery: Code: 394. DB::Exception: Query was cancelled. (QUERY_WAS_CANCELLED) (version 25.3.6.10636.altinitytest (altinity build)) (from [::1]:55648) (comment: 02461_cancel_finish_race.sh) (query 1, line 1) (in query: KILL QUERY WHERE current_database = 'test_dtwle8fg' SYNC FORMAT Null), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000000a074fcb 4. /build/src/Interpreters/ProcessList.cpp:567: DB::QueryStatus::throwQueryWasCancelled() const @ 0x0000000014a4bc85 5. /build/src/Interpreters/ProcessList.cpp:520: DB::QueryStatus::throwProperExceptionIfNeeded(unsigned long const&, unsigned long const&) @ 0x0000000014a4bbd9 6. /build/src/Interpreters/ProcessList.cpp:557: DB::QueryStatus::checkTimeLimit() @ 0x0000000014a4c2cd 7. /build/src/Processors/Executors/PipelineExecutor.cpp:206: DB::PipelineExecutor::finalizeExecution() @ 0x00000000169b13ba 8. /build/src/Processors/Executors/PipelineExecutor.cpp:153: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x00000000169b0584 9. /build/src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:se190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169bfeab 10. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc3d92 11. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fcca080 12. ? @ 0x00007fbc6213eac3 13. ? @ 0x00007fbc621d0850 2025.07.28 12:02:35.453787 [ 17252 ] {} TCPHandler: Code: 394. DB::Exception: Query was cancelled. (QUERY_WAS_CANCELLED), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000000a074fcb 4. /build/src/Interpreters/ProcessList.cpp:567: DB::QueryStatus::throwQueryWasCancelled() const @ 0x0000000014a4bc85 5. /build/src/Interpreters/ProcessList.cpp:520: DB::QueryStatus::throwProperExceptionIfNeeded(unsigned long const&, unsigned long const&) @ 0x0000000014a4bbd9 6. /build/src/Interpreters/ProcessList.cpp:557: DB::QueryStatus::checkTimeLimit() @ 0x0000000014a4c2cd 7. /build/src/Processors/Executors/PipelineExecutor.cpp:206: DB::PipelineExecutor::finalizeExecution() @ 0x00000000169b13ba 8. /build/src/Processors/Executors/PipelineExecutor.cpp:153: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x00000000169b0584 9. /build/src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:se190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169bfeab 10. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc3d92 11. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fcca080 12. ? @ 0x00007fbc6213eac3 13. ? @ 0x00007fbc621d0850 Job's origin stack trace: 0. /build/src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000000fc33b84 1. /build/src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000000fcc2ea7 2. /build/src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fcc535c 3. /build/src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000000fcc584d 4. /build/src/Common/ThreadPool.h:279: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x00000000169bf193 5. /build/src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x00000000169bf518 6. /build/src/Server/TCPHandler.cpp:1237: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x00000000168f1525 7. /build/src/Server/TCPHandler.cpp:678: DB::TCPHandler::runImpl() @ 0x00000000168e68e5 8. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 9. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 10. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 11. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 12. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 13. ? @ 0x00007fbc6213eac3 14. ? @ 0x00007fbc621d0850 2025.07.28 12:02:35.454668 [ 17611 ] {} TCPHandler: Code: 394. DB::Exception: Query was cancelled. (QUERY_WAS_CANCELLED), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000000a074fcb 4. /build/src/Interpreters/ProcessList.cpp:567: DB::QueryStatus::throwQueryWasCancelled() const @ 0x0000000014a4bc85 5. /build/src/Interpreters/ProcessList.cpp:520: DB::QueryStatus::throwProperExceptionIfNeeded(unsigned long const&, unsigned long const&) @ 0x0000000014a4bbd9 6. /build/src/Interpreters/ProcessList.cpp:557: DB::QueryStatus::checkTimeLimit() @ 0x0000000014a4c2cd 7. /build/src/Processors/Executors/PipelineExecutor.cpp:206: DB::PipelineExecutor::finalizeExecution() @ 0x00000000169b13ba 8. /build/src/Processors/Executors/PipelineExecutor.cpp:153: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x00000000169b0584 9. /build/src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:se190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169bfeab 10. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc3d92 11. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fcca080 12. ? @ 0x00007fbc6213eac3 13. ? @ 0x00007fbc621d0850 Job's origin stack trace: 0. /build/src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000000fc33b84 1. /build/src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000000fcc2ea7 2. /build/src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fcc535c 3. /build/src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000000fcc584d 4. /build/src/Common/ThreadPool.h:279: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x00000000169bf193 5. /build/src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x00000000169bf518 6. /build/src/Server/TCPHandler.cpp:1237: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x00000000168f1525 7. /build/src/Server/TCPHandler.cpp:678: DB::TCPHandler::runImpl() @ 0x00000000168e68e5 8. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 9. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 10. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 11. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 12. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 13. ? @ 0x00007fbc6213eac3 14. ? @ 0x00007fbc621d0850 2025.07.28 12:02:35.496796 [ 3969 ] {} test_13.rmt2 (7f9b740d-015c-470e-8cc6-8ba33be0dc63): auto DB::StorageReplicatedMergeTree::processQueueEntry(ReplicatedMergeTreeQueue::SelectedEntryPtr)::(anonymous class)::operator()(LogEntryPtr &) const: Code: 86. DB::HTTPException: Received error from remote server http://146b4357c08d:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Ftest%2F01165%2Ftest_13%2Frmt%2Freplicas%2F1&part=20250728_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.6.10636.altinitytest (altinity build)) '. (RECEIVED_ERROR_FROM_REMOTE_IO_SERVER), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.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 const&, int&&, String const&, unsigned long&&, String const&) @ 0x000000000feda8d9 4. /build/src/IO/HTTPCommon.cpp:104: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x000000000feda6e2 5. /build/src/IO/HTTPCommon.cpp:93: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x000000000feda537 6. /build/src/IO/ReadWriteBufferFromHTTP.cpp:277: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x000000001184a4c4 7. /build/src/IO/ReadWriteBufferFromHTTP.cpp:285: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x000000001184a615 8. /build/src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x000000001184ae59 9. /build/src/IO/ReadWriteBufferFromHTTP.cpp:472: void std::__function::__policy_invoker::__call_impl[abi:se190107]>(std::__function::__policy_storage const*) @ 0x000000001184cedd 10. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001184858b 11. /build/src/IO/ReadWriteBufferFromHTTP.cpp:465: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x000000001184bf0b 12. /build/src/IO/ReadBuffer.h:60: DB::ReadBuffer::next() @ 0x000000000a148c7b 13. /build/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) @ 0x0000000011849fb2 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]>&)>&, 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&) @ 0x0000000011841980 15. /build/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) @ 0x000000001621208e 16. /build/src/Storages/StorageReplicatedMergeTree.cpp:5228: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl[abi:se190107] const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000015f9a5fe 17. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000015ed8bfd 18. /build/src/Storages/StorageReplicatedMergeTree.cpp:2514: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x0000000015ec9aab 19. /build/src/Storages/StorageReplicatedMergeTree.cpp:2349: DB::StorageReplicatedMergeTree::executeLogEntry(DB::ReplicatedMergeTreeLogEntry&) @ 0x0000000015eba91b 20. /build/src/Storages/StorageReplicatedMergeTree.cpp:3876: bool std::__function::__policy_invoker&)>::__call_impl[abi:se190107])::$_1, bool (std::shared_ptr&)>>(std::__function::__policy_storage const*, std::shared_ptr&) @ 0x0000000015f9837e 21. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000165d6fc3 22. /build/src/Storages/StorageReplicatedMergeTree.cpp:3872: DB::StorageReplicatedMergeTree::processQueueEntry(std::shared_ptr) @ 0x0000000015efc18a 23. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001624c1b2 24. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000162f9c70 25. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x00000000162fa55a 26. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc6653 27. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000000fccc4c3 28. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc3d92 29. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fcca080 30. ? @ 0x00007fbc6213eac3 31. ? @ 0x00007fbc621d0850 (version 25.3.6.10636.altinitytest (altinity build)) 2025.07.28 12:02:35.510444 [ 4900 ] {} TCPHandler: Code: 394. DB::Exception: Query was cancelled. (QUERY_WAS_CANCELLED), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000000a074fcb 4. /build/src/Interpreters/ProcessList.cpp:567: DB::QueryStatus::throwQueryWasCancelled() const @ 0x0000000014a4bc85 5. /build/src/Interpreters/ProcessList.cpp:520: DB::QueryStatus::throwProperExceptionIfNeeded(unsigned long const&, unsigned long const&) @ 0x0000000014a4bbd9 6. /build/src/Interpreters/ProcessList.cpp:531: DB::QueryStatus::addPipelineExecutor(DB::PipelineExecutor*) @ 0x0000000014a4bd9c 7. /build/src/Processors/Executors/PipelineExecutor.cpp:73: DB::PipelineExecutor::PipelineExecutor(std::shared_ptr, std::allocator>>>&, std::shared_ptr) @ 0x00000000169afe31 8. /build/contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x00000000169c07b5 9. /build/src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x00000000169c0978 10. /build/src/Interpreters/InterpreterKillQueryQuery.cpp:439: DB::InterpreterKillQueryQuery::getSelectResult(String const&, String const&) @ 0x0000000014cf0f04 11. /build/src/Interpreters/InterpreterKillQueryQuery.cpp:222: DB::InterpreterKillQueryQuery::execute() @ 0x0000000014cebde2 12. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88dc9 13. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 14. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 15. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 16. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 17. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 18. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 19. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 20. ? @ 0x00007fbc6213eac3 21. ? @ 0x00007fbc621d0850 2025.07.28 12:02:35.728149 [ 17243 ] {7b1805a1-78ca-40bb-87eb-6e90541b6746} executeQuery: Code: 394. DB::Exception: Query was cancelled. (QUERY_WAS_CANCELLED) (version 25.3.6.10636.altinitytest (altinity build)) (from [::1]:55788) (comment: 02461_cancel_finish_race.sh) (query 1, line 1) (in query: KILL QUERY WHERE current_database = 'test_dtwle8fg' SYNC FORMAT Null), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000000a074fcb 4. /build/src/Interpreters/ProcessList.cpp:567: DB::QueryStatus::throwQueryWasCancelled() const @ 0x0000000014a4bc85 5. /build/src/Interpreters/ProcessList.cpp:520: DB::QueryStatus::throwProperExceptionIfNeeded(unsigned long const&, unsigned long const&) @ 0x0000000014a4bbd9 6. /build/src/Interpreters/ProcessList.cpp:557: DB::QueryStatus::checkTimeLimit() @ 0x0000000014a4c2cd 7. /build/src/Processors/Executors/PipelineExecutor.cpp:206: DB::PipelineExecutor::finalizeExecution() @ 0x00000000169b13ba 8. /build/src/Processors/Executors/PipelineExecutor.cpp:153: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x00000000169b0584 9. /build/src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:se190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169bfeab 10. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc3d92 11. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fcca080 12. ? @ 0x00007fbc6213eac3 13. ? @ 0x00007fbc621d0850 2025.07.28 12:02:35.737461 [ 17256 ] {55e4f861-dd01-4bf0-a160-1524b88c6939} executeQuery: Code: 394. DB::Exception: Query was cancelled. (QUERY_WAS_CANCELLED) (version 25.3.6.10636.altinitytest (altinity build)) (from [::1]:55818) (comment: 02461_cancel_finish_race.sh) (query 1, line 1) (in query: KILL QUERY WHERE current_database = 'test_dtwle8fg' SYNC FORMAT Null), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000000a074fcb 4. /build/src/Interpreters/ProcessList.cpp:567: DB::QueryStatus::throwQueryWasCancelled() const @ 0x0000000014a4bc85 5. /build/src/Interpreters/ProcessList.cpp:520: DB::QueryStatus::throwProperExceptionIfNeeded(unsigned long const&, unsigned long const&) @ 0x0000000014a4bbd9 6. /build/src/Interpreters/ProcessList.cpp:557: DB::QueryStatus::checkTimeLimit() @ 0x0000000014a4c2cd 7. /build/src/Processors/Executors/PipelineExecutor.cpp:206: DB::PipelineExecutor::finalizeExecution() @ 0x00000000169b13ba 8. /build/src/Processors/Executors/PipelineExecutor.cpp:153: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x00000000169b0584 9. /build/src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:se190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169bfeab 10. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc3d92 11. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fcca080 12. ? @ 0x00007fbc6213eac3 13. ? @ 0x00007fbc621d0850 2025.07.28 12:02:35.846066 [ 62055 ] {} TCPHandler: Code: 394. DB::Exception: Query was cancelled. (QUERY_WAS_CANCELLED), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000000a074fcb 4. /build/src/Interpreters/ProcessList.cpp:567: DB::QueryStatus::throwQueryWasCancelled() const @ 0x0000000014a4bc85 5. /build/src/Interpreters/ProcessList.cpp:520: DB::QueryStatus::throwProperExceptionIfNeeded(unsigned long const&, unsigned long const&) @ 0x0000000014a4bbd9 6. /build/src/Interpreters/ProcessList.cpp:557: DB::QueryStatus::checkTimeLimit() @ 0x0000000014a4c2cd 7. /build/src/Processors/Executors/PipelineExecutor.cpp:206: DB::PipelineExecutor::finalizeExecution() @ 0x00000000169b13ba 8. /build/src/Processors/Executors/PipelineExecutor.cpp:181: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x00000000169b1726 9. /build/src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x00000000169c081c 10. /build/src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x00000000169c0978 11. /build/src/Interpreters/InterpreterKillQueryQuery.cpp:442: DB::InterpreterKillQueryQuery::getSelectResult(String const&, String const&) @ 0x0000000014cf0f6b 12. /build/src/Interpreters/InterpreterKillQueryQuery.cpp:222: DB::InterpreterKillQueryQuery::execute() @ 0x0000000014cebde2 13. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88dc9 14. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 15. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 16. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 17. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 18. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 19. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 20. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 21. ? @ 0x00007fbc6213eac3 22. ? @ 0x00007fbc621d0850 2025.07.28 12:02:35.847118 [ 17243 ] {} TCPHandler: Code: 394. DB::Exception: Query was cancelled. (QUERY_WAS_CANCELLED), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000000a074fcb 4. /build/src/Interpreters/ProcessList.cpp:567: DB::QueryStatus::throwQueryWasCancelled() const @ 0x0000000014a4bc85 5. /build/src/Interpreters/ProcessList.cpp:520: DB::QueryStatus::throwProperExceptionIfNeeded(unsigned long const&, unsigned long const&) @ 0x0000000014a4bbd9 6. /build/src/Interpreters/ProcessList.cpp:557: DB::QueryStatus::checkTimeLimit() @ 0x0000000014a4c2cd 7. /build/src/Processors/Executors/PipelineExecutor.cpp:206: DB::PipelineExecutor::finalizeExecution() @ 0x00000000169b13ba 8. /build/src/Processors/Executors/PipelineExecutor.cpp:153: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x00000000169b0584 9. /build/src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:se190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169bfeab 10. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc3d92 11. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fcca080 12. ? @ 0x00007fbc6213eac3 13. ? @ 0x00007fbc621d0850 Job's origin stack trace: 0. /build/src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000000fc33b84 1. /build/src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000000fcc2ea7 2. /build/src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fcc535c 3. /build/src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000000fcc584d 4. /build/src/Common/ThreadPool.h:279: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x00000000169bf193 5. /build/src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x00000000169bf518 6. /build/src/Server/TCPHandler.cpp:1237: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x00000000168f1525 7. /build/src/Server/TCPHandler.cpp:678: DB::TCPHandler::runImpl() @ 0x00000000168e68e5 8. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 9. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 10. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 11. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 12. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 13. ? @ 0x00007fbc6213eac3 14. ? @ 0x00007fbc621d0850 2025.07.28 12:02:35.847322 [ 62093 ] {c8949e7b-27c5-49c2-9207-a3da2b4f6bdb} executeQuery: Code: 394. DB::Exception: Query was cancelled. (QUERY_WAS_CANCELLED) (version 25.3.6.10636.altinitytest (altinity build)) (from [::1]:55796) (comment: 02461_cancel_finish_race.sh) (query 1, line 1) (in query: KILL QUERY WHERE current_database = 'test_dtwle8fg' SYNC FORMAT Null), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000000a074fcb 4. /build/src/Interpreters/ProcessList.cpp:567: DB::QueryStatus::throwQueryWasCancelled() const @ 0x0000000014a4bc85 5. /build/src/Interpreters/ProcessList.cpp:520: DB::QueryStatus::throwProperExceptionIfNeeded(unsigned long const&, unsigned long const&) @ 0x0000000014a4bbd9 6. /build/src/Interpreters/ProcessList.cpp:557: DB::QueryStatus::checkTimeLimit() @ 0x0000000014a4c2cd 7. /build/src/Processors/Executors/PipelineExecutor.cpp:206: DB::PipelineExecutor::finalizeExecution() @ 0x00000000169b13ba 8. /build/src/Processors/Executors/PipelineExecutor.cpp:153: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x00000000169b0584 9. /build/src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:se190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169bfeab 10. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc3d92 11. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fcca080 12. ? @ 0x00007fbc6213eac3 13. ? @ 0x00007fbc621d0850 2025.07.28 12:02:35.847553 [ 17256 ] {} TCPHandler: Code: 394. DB::Exception: Query was cancelled. (QUERY_WAS_CANCELLED), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000000a074fcb 4. /build/src/Interpreters/ProcessList.cpp:567: DB::QueryStatus::throwQueryWasCancelled() const @ 0x0000000014a4bc85 5. /build/src/Interpreters/ProcessList.cpp:520: DB::QueryStatus::throwProperExceptionIfNeeded(unsigned long const&, unsigned long const&) @ 0x0000000014a4bbd9 6. /build/src/Interpreters/ProcessList.cpp:557: DB::QueryStatus::checkTimeLimit() @ 0x0000000014a4c2cd 7. /build/src/Processors/Executors/PipelineExecutor.cpp:206: DB::PipelineExecutor::finalizeExecution() @ 0x00000000169b13ba 8. /build/src/Processors/Executors/PipelineExecutor.cpp:153: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x00000000169b0584 9. /build/src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:se190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169bfeab 10. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc3d92 11. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fcca080 12. ? @ 0x00007fbc6213eac3 13. ? @ 0x00007fbc621d0850 Job's origin stack trace: 0. /build/src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000000fc33b84 1. /build/src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000000fcc2ea7 2. /build/src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fcc535c 3. /build/src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000000fcc584d 4. /build/src/Common/ThreadPool.h:279: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x00000000169bf193 5. /build/src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x00000000169bf518 6. /build/src/Server/TCPHandler.cpp:1237: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x00000000168f1525 7. /build/src/Server/TCPHandler.cpp:678: DB::TCPHandler::runImpl() @ 0x00000000168e68e5 8. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 9. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 10. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 11. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 12. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 13. ? @ 0x00007fbc6213eac3 14. ? @ 0x00007fbc621d0850 2025.07.28 12:02:35.859304 [ 62093 ] {} TCPHandler: Code: 394. DB::Exception: Query was cancelled. (QUERY_WAS_CANCELLED), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000000a074fcb 4. /build/src/Interpreters/ProcessList.cpp:567: DB::QueryStatus::throwQueryWasCancelled() const @ 0x0000000014a4bc85 5. /build/src/Interpreters/ProcessList.cpp:520: DB::QueryStatus::throwProperExceptionIfNeeded(unsigned long const&, unsigned long const&) @ 0x0000000014a4bbd9 6. /build/src/Interpreters/ProcessList.cpp:557: DB::QueryStatus::checkTimeLimit() @ 0x0000000014a4c2cd 7. /build/src/Processors/Executors/PipelineExecutor.cpp:206: DB::PipelineExecutor::finalizeExecution() @ 0x00000000169b13ba 8. /build/src/Processors/Executors/PipelineExecutor.cpp:153: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x00000000169b0584 9. /build/src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:se190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169bfeab 10. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc3d92 11. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fcca080 12. ? @ 0x00007fbc6213eac3 13. ? @ 0x00007fbc621d0850 Job's origin stack trace: 0. /build/src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000000fc33b84 1. /build/src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000000fcc2ea7 2. /build/src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fcc535c 3. /build/src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000000fcc584d 4. /build/src/Common/ThreadPool.h:279: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x00000000169bf193 5. /build/src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x00000000169bf518 6. /build/src/Server/TCPHandler.cpp:1237: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x00000000168f1525 7. /build/src/Server/TCPHandler.cpp:678: DB::TCPHandler::runImpl() @ 0x00000000168e68e5 8. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 9. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 10. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 11. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 12. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 13. ? @ 0x00007fbc6213eac3 14. ? @ 0x00007fbc621d0850 2025.07.28 12:02:35.864597 [ 17371 ] {} TCPHandler: Code: 394. DB::Exception: Query was cancelled. (QUERY_WAS_CANCELLED), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000000a074fcb 4. /build/src/Interpreters/ProcessList.cpp:567: DB::QueryStatus::throwQueryWasCancelled() const @ 0x0000000014a4bc85 5. /build/src/Interpreters/ProcessList.cpp:520: DB::QueryStatus::throwProperExceptionIfNeeded(unsigned long const&, unsigned long const&) @ 0x0000000014a4bbd9 6. /build/src/Interpreters/ProcessList.cpp:557: DB::QueryStatus::checkTimeLimit() @ 0x0000000014a4c2cd 7. /build/src/Processors/Executors/PipelineExecutor.cpp:206: DB::PipelineExecutor::finalizeExecution() @ 0x00000000169b13ba 8. /build/src/Processors/Executors/PipelineExecutor.cpp:181: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x00000000169b1726 9. /build/src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x00000000169c081c 10. /build/src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x00000000169c0978 11. /build/src/Interpreters/InterpreterKillQueryQuery.cpp:439: DB::InterpreterKillQueryQuery::getSelectResult(String const&, String const&) @ 0x0000000014cf0f04 12. /build/src/Interpreters/InterpreterKillQueryQuery.cpp:222: DB::InterpreterKillQueryQuery::execute() @ 0x0000000014cebde2 13. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88dc9 14. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 15. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 16. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 17. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 18. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 19. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 20. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 21. ? @ 0x00007fbc6213eac3 22. ? @ 0x00007fbc621d0850 2025.07.28 12:02:35.991140 [ 17203 ] {} TCPHandler: Code: 394. DB::Exception: Query was cancelled. (QUERY_WAS_CANCELLED), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000000a074fcb 4. /build/src/Interpreters/ProcessList.cpp:567: DB::QueryStatus::throwQueryWasCancelled() const @ 0x0000000014a4bc85 5. /build/src/Interpreters/ProcessList.cpp:520: DB::QueryStatus::throwProperExceptionIfNeeded(unsigned long const&, unsigned long const&) @ 0x0000000014a4bbd9 6. /build/src/Interpreters/ProcessList.cpp:531: DB::QueryStatus::addPipelineExecutor(DB::PipelineExecutor*) @ 0x0000000014a4bd9c 7. /build/src/Processors/Executors/PipelineExecutor.cpp:73: DB::PipelineExecutor::PipelineExecutor(std::shared_ptr, std::allocator>>>&, std::shared_ptr) @ 0x00000000169afe31 8. /build/contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x00000000169c07b5 9. /build/src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x00000000169c0978 10. /build/src/Interpreters/InterpreterKillQueryQuery.cpp:439: DB::InterpreterKillQueryQuery::getSelectResult(String const&, String const&) @ 0x0000000014cf0f04 11. /build/src/Interpreters/InterpreterKillQueryQuery.cpp:222: DB::InterpreterKillQueryQuery::execute() @ 0x0000000014cebde2 12. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88dc9 13. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 14. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 15. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 16. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 17. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 18. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 19. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 20. ? @ 0x00007fbc6213eac3 21. ? @ 0x00007fbc621d0850 2025.07.28 12:02:36.132271 [ 17232 ] {20f86fd3-48a9-41ac-b3e1-77add682a8e1} executeQuery: Code: 394. DB::Exception: Query was cancelled. (QUERY_WAS_CANCELLED) (version 25.3.6.10636.altinitytest (altinity build)) (from [::1]:55872) (comment: 02461_cancel_finish_race.sh) (query 1, line 1) (in query: KILL QUERY WHERE current_database = 'test_dtwle8fg' SYNC FORMAT Null), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000000a074fcb 4. /build/src/Interpreters/ProcessList.cpp:567: DB::QueryStatus::throwQueryWasCancelled() const @ 0x0000000014a4bc85 5. /build/src/Interpreters/ProcessList.cpp:520: DB::QueryStatus::throwProperExceptionIfNeeded(unsigned long const&, unsigned long const&) @ 0x0000000014a4bbd9 6. /build/src/Interpreters/ProcessList.cpp:557: DB::QueryStatus::checkTimeLimit() @ 0x0000000014a4c2cd 7. /build/src/Processors/Executors/PipelineExecutor.cpp:206: DB::PipelineExecutor::finalizeExecution() @ 0x00000000169b13ba 8. /build/src/Processors/Executors/PipelineExecutor.cpp:153: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x00000000169b0584 9. /build/src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:se190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169bfeab 10. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc3d92 11. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fcca080 12. ? @ 0x00007fbc6213eac3 13. ? @ 0x00007fbc621d0850 2025.07.28 12:02:36.133574 [ 4900 ] {c3746ab6-2a22-4041-9de3-786fa62a6701} executeQuery: Code: 394. DB::Exception: Query was cancelled. (QUERY_WAS_CANCELLED) (version 25.3.6.10636.altinitytest (altinity build)) (from [::1]:55894) (comment: 02461_cancel_finish_race.sh) (query 1, line 1) (in query: KILL QUERY WHERE current_database = 'test_dtwle8fg' SYNC FORMAT Null), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000000a074fcb 4. /build/src/Interpreters/ProcessList.cpp:567: DB::QueryStatus::throwQueryWasCancelled() const @ 0x0000000014a4bc85 5. /build/src/Interpreters/ProcessList.cpp:520: DB::QueryStatus::throwProperExceptionIfNeeded(unsigned long const&, unsigned long const&) @ 0x0000000014a4bbd9 6. /build/src/Interpreters/ProcessList.cpp:557: DB::QueryStatus::checkTimeLimit() @ 0x0000000014a4c2cd 7. /build/src/Processors/Executors/PipelineExecutor.cpp:206: DB::PipelineExecutor::finalizeExecution() @ 0x00000000169b13ba 8. /build/src/Processors/Executors/PipelineExecutor.cpp:153: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x00000000169b0584 9. /build/src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:se190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169bfeab 10. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc3d92 11. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fcca080 12. ? @ 0x00007fbc6213eac3 13. ? @ 0x00007fbc621d0850 2025.07.28 12:02:36.157884 [ 4900 ] {} TCPHandler: Code: 394. DB::Exception: Query was cancelled. (QUERY_WAS_CANCELLED), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000000a074fcb 4. /build/src/Interpreters/ProcessList.cpp:567: DB::QueryStatus::throwQueryWasCancelled() const @ 0x0000000014a4bc85 5. /build/src/Interpreters/ProcessList.cpp:520: DB::QueryStatus::throwProperExceptionIfNeeded(unsigned long const&, unsigned long const&) @ 0x0000000014a4bbd9 6. /build/src/Interpreters/ProcessList.cpp:557: DB::QueryStatus::checkTimeLimit() @ 0x0000000014a4c2cd 7. /build/src/Processors/Executors/PipelineExecutor.cpp:206: DB::PipelineExecutor::finalizeExecution() @ 0x00000000169b13ba 8. /build/src/Processors/Executors/PipelineExecutor.cpp:153: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x00000000169b0584 9. /build/src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:se190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169bfeab 10. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc3d92 11. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fcca080 12. ? @ 0x00007fbc6213eac3 13. ? @ 0x00007fbc621d0850 Job's origin stack trace: 0. /build/src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000000fc33b84 1. /build/src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000000fcc2ea7 2. /build/src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fcc535c 3. /build/src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000000fcc584d 4. /build/src/Common/ThreadPool.h:279: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x00000000169bf193 5. /build/src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x00000000169bf518 6. /build/src/Server/TCPHandler.cpp:1237: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x00000000168f1525 7. /build/src/Server/TCPHandler.cpp:678: DB::TCPHandler::runImpl() @ 0x00000000168e68e5 8. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 9. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 10. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 11. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 12. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 13. ? @ 0x00007fbc6213eac3 14. ? @ 0x00007fbc621d0850 2025.07.28 12:02:36.157877 [ 17232 ] {} TCPHandler: Code: 394. DB::Exception: Query was cancelled. (QUERY_WAS_CANCELLED), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000000a074fcb 4. /build/src/Interpreters/ProcessList.cpp:567: DB::QueryStatus::throwQueryWasCancelled() const @ 0x0000000014a4bc85 5. /build/src/Interpreters/ProcessList.cpp:520: DB::QueryStatus::throwProperExceptionIfNeeded(unsigned long const&, unsigned long const&) @ 0x0000000014a4bbd9 6. /build/src/Interpreters/ProcessList.cpp:557: DB::QueryStatus::checkTimeLimit() @ 0x0000000014a4c2cd 7. /build/src/Processors/Executors/PipelineExecutor.cpp:206: DB::PipelineExecutor::finalizeExecution() @ 0x00000000169b13ba 8. /build/src/Processors/Executors/PipelineExecutor.cpp:153: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x00000000169b0584 9. /build/src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:se190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169bfeab 10. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc3d92 11. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fcca080 12. ? @ 0x00007fbc6213eac3 13. ? @ 0x00007fbc621d0850 Job's origin stack trace: 0. /build/src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000000fc33b84 1. /build/src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000000fcc2ea7 2. /build/src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fcc535c 3. /build/src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000000fcc584d 4. /build/src/Common/ThreadPool.h:279: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x00000000169bf193 5. /build/src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x00000000169bf518 6. /build/src/Server/TCPHandler.cpp:1237: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x00000000168f1525 7. /build/src/Server/TCPHandler.cpp:678: DB::TCPHandler::runImpl() @ 0x00000000168e68e5 8. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 9. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 10. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 11. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 12. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 13. ? @ 0x00007fbc6213eac3 14. ? @ 0x00007fbc621d0850 2025.07.28 12:02:36.204925 [ 62314 ] {fa259e0d-1734-4991-a473-d7e3c82b98f1} executeQuery: Code: 394. DB::Exception: Query was cancelled. (QUERY_WAS_CANCELLED) (version 25.3.6.10636.altinitytest (altinity build)) (from [::1]:55896) (comment: 02461_cancel_finish_race.sh) (query 1, line 1) (in query: KILL QUERY WHERE current_database = 'test_dtwle8fg' SYNC FORMAT Null), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000000a074fcb 4. /build/src/Interpreters/ProcessList.cpp:567: DB::QueryStatus::throwQueryWasCancelled() const @ 0x0000000014a4bc85 5. /build/src/Interpreters/ProcessList.cpp:520: DB::QueryStatus::throwProperExceptionIfNeeded(unsigned long const&, unsigned long const&) @ 0x0000000014a4bbd9 6. /build/src/Interpreters/ProcessList.cpp:557: DB::QueryStatus::checkTimeLimit() @ 0x0000000014a4c2cd 7. /build/src/Processors/Executors/PipelineExecutor.cpp:206: DB::PipelineExecutor::finalizeExecution() @ 0x00000000169b13ba 8. /build/src/Processors/Executors/PipelineExecutor.cpp:153: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x00000000169b0584 9. /build/src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:se190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169bfeab 10. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc3d92 11. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fcca080 12. ? @ 0x00007fbc6213eac3 13. ? @ 0x00007fbc621d0850 2025.07.28 12:02:36.232196 [ 62314 ] {} TCPHandler: Code: 394. DB::Exception: Query was cancelled. (QUERY_WAS_CANCELLED), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000000a074fcb 4. /build/src/Interpreters/ProcessList.cpp:567: DB::QueryStatus::throwQueryWasCancelled() const @ 0x0000000014a4bc85 5. /build/src/Interpreters/ProcessList.cpp:520: DB::QueryStatus::throwProperExceptionIfNeeded(unsigned long const&, unsigned long const&) @ 0x0000000014a4bbd9 6. /build/src/Interpreters/ProcessList.cpp:557: DB::QueryStatus::checkTimeLimit() @ 0x0000000014a4c2cd 7. /build/src/Processors/Executors/PipelineExecutor.cpp:206: DB::PipelineExecutor::finalizeExecution() @ 0x00000000169b13ba 8. /build/src/Processors/Executors/PipelineExecutor.cpp:153: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x00000000169b0584 9. /build/src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:se190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169bfeab 10. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc3d92 11. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fcca080 12. ? @ 0x00007fbc6213eac3 13. ? @ 0x00007fbc621d0850 Job's origin stack trace: 0. /build/src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000000fc33b84 1. /build/src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000000fcc2ea7 2. /build/src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fcc535c 3. /build/src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000000fcc584d 4. /build/src/Common/ThreadPool.h:279: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x00000000169bf193 5. /build/src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x00000000169bf518 6. /build/src/Server/TCPHandler.cpp:1237: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x00000000168f1525 7. /build/src/Server/TCPHandler.cpp:678: DB::TCPHandler::runImpl() @ 0x00000000168e68e5 8. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 9. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 10. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 11. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 12. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 13. ? @ 0x00007fbc6213eac3 14. ? @ 0x00007fbc621d0850 2025.07.28 12:02:36.283724 [ 3977 ] {} test_13.rmt2 (7f9b740d-015c-470e-8cc6-8ba33be0dc63): auto DB::StorageReplicatedMergeTree::processQueueEntry(ReplicatedMergeTreeQueue::SelectedEntryPtr)::(anonymous class)::operator()(LogEntryPtr &) const: Code: 86. DB::HTTPException: Received error from remote server http://146b4357c08d:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Ftest%2F01165%2Ftest_13%2Frmt%2Freplicas%2F1&part=20250728_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.6.10636.altinitytest (altinity build)) '. (RECEIVED_ERROR_FROM_REMOTE_IO_SERVER), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.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 const&, int&&, String const&, unsigned long&&, String const&) @ 0x000000000feda8d9 4. /build/src/IO/HTTPCommon.cpp:104: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x000000000feda6e2 5. /build/src/IO/HTTPCommon.cpp:93: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x000000000feda537 6. /build/src/IO/ReadWriteBufferFromHTTP.cpp:277: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x000000001184a4c4 7. /build/src/IO/ReadWriteBufferFromHTTP.cpp:285: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x000000001184a615 8. /build/src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x000000001184ae59 9. /build/src/IO/ReadWriteBufferFromHTTP.cpp:472: void std::__function::__policy_invoker::__call_impl[abi:se190107]>(std::__function::__policy_storage const*) @ 0x000000001184cedd 10. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001184858b 11. /build/src/IO/ReadWriteBufferFromHTTP.cpp:465: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x000000001184bf0b 12. /build/src/IO/ReadBuffer.h:60: DB::ReadBuffer::next() @ 0x000000000a148c7b 13. /build/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) @ 0x0000000011849fb2 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]>&)>&, 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&) @ 0x0000000011841980 15. /build/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) @ 0x000000001621208e 16. /build/src/Storages/StorageReplicatedMergeTree.cpp:5228: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl[abi:se190107] const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000015f9a5fe 17. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000015ed8bfd 18. /build/src/Storages/StorageReplicatedMergeTree.cpp:2514: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x0000000015ec9aab 19. /build/src/Storages/StorageReplicatedMergeTree.cpp:2349: DB::StorageReplicatedMergeTree::executeLogEntry(DB::ReplicatedMergeTreeLogEntry&) @ 0x0000000015eba91b 20. /build/src/Storages/StorageReplicatedMergeTree.cpp:3876: bool std::__function::__policy_invoker&)>::__call_impl[abi:se190107])::$_1, bool (std::shared_ptr&)>>(std::__function::__policy_storage const*, std::shared_ptr&) @ 0x0000000015f9837e 21. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000165d6fc3 22. /build/src/Storages/StorageReplicatedMergeTree.cpp:3872: DB::StorageReplicatedMergeTree::processQueueEntry(std::shared_ptr) @ 0x0000000015efc18a 23. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001624c1b2 24. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000162f9c70 25. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x00000000162fa55a 26. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc6653 27. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000000fccc4c3 28. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc3d92 29. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fcca080 30. ? @ 0x00007fbc6213eac3 31. ? @ 0x00007fbc621d0850 (version 25.3.6.10636.altinitytest (altinity build)) 2025.07.28 12:02:36.362127 [ 17243 ] {33bb0599-9d22-4066-a7f7-6a1d61fc9dfe} executeQuery: Code: 394. DB::Exception: Query was cancelled. (QUERY_WAS_CANCELLED) (version 25.3.6.10636.altinitytest (altinity build)) (from [::1]:55970) (comment: 02461_cancel_finish_race.sh) (query 1, line 1) (in query: KILL QUERY WHERE current_database = 'test_dtwle8fg' SYNC FORMAT Null), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000000a074fcb 4. /build/src/Interpreters/ProcessList.cpp:567: DB::QueryStatus::throwQueryWasCancelled() const @ 0x0000000014a4bc85 5. /build/src/Interpreters/ProcessList.cpp:520: DB::QueryStatus::throwProperExceptionIfNeeded(unsigned long const&, unsigned long const&) @ 0x0000000014a4bbd9 6. /build/src/Interpreters/ProcessList.cpp:531: DB::QueryStatus::addPipelineExecutor(DB::PipelineExecutor*) @ 0x0000000014a4bd9c 7. /build/src/Processors/Executors/PipelineExecutor.cpp:73: DB::PipelineExecutor::PipelineExecutor(std::shared_ptr, std::allocator>>>&, std::shared_ptr) @ 0x00000000169afe31 8. /build/contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x00000000169bef66 9. /build/src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x00000000169bf518 10. /build/src/Server/TCPHandler.cpp:1237: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x00000000168f1525 11. /build/src/Server/TCPHandler.cpp:678: DB::TCPHandler::runImpl() @ 0x00000000168e68e5 12. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 13. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 14. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 16. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 17. ? @ 0x00007fbc6213eac3 18. ? @ 0x00007fbc621d0850 2025.07.28 12:02:36.414121 [ 17243 ] {} TCPHandler: Code: 394. DB::Exception: Query was cancelled. (QUERY_WAS_CANCELLED), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000000a074fcb 4. /build/src/Interpreters/ProcessList.cpp:567: DB::QueryStatus::throwQueryWasCancelled() const @ 0x0000000014a4bc85 5. /build/src/Interpreters/ProcessList.cpp:520: DB::QueryStatus::throwProperExceptionIfNeeded(unsigned long const&, unsigned long const&) @ 0x0000000014a4bbd9 6. /build/src/Interpreters/ProcessList.cpp:531: DB::QueryStatus::addPipelineExecutor(DB::PipelineExecutor*) @ 0x0000000014a4bd9c 7. /build/src/Processors/Executors/PipelineExecutor.cpp:73: DB::PipelineExecutor::PipelineExecutor(std::shared_ptr, std::allocator>>>&, std::shared_ptr) @ 0x00000000169afe31 8. /build/contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x00000000169bef66 9. /build/src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x00000000169bf518 10. /build/src/Server/TCPHandler.cpp:1237: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x00000000168f1525 11. /build/src/Server/TCPHandler.cpp:678: DB::TCPHandler::runImpl() @ 0x00000000168e68e5 12. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 13. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 14. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 16. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 17. ? @ 0x00007fbc6213eac3 18. ? @ 0x00007fbc621d0850 2025.07.28 12:02:36.435073 [ 62055 ] {89108f46-75e9-4603-b836-1f5b61f2bc11} executeQuery: Code: 394. DB::Exception: Query was cancelled. (QUERY_WAS_CANCELLED) (version 25.3.6.10636.altinitytest (altinity build)) (from [::1]:55978) (comment: 02461_cancel_finish_race.sh) (query 1, line 1) (in query: KILL QUERY WHERE current_database = 'test_dtwle8fg' SYNC FORMAT Null), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000000a074fcb 4. /build/src/Interpreters/ProcessList.cpp:567: DB::QueryStatus::throwQueryWasCancelled() const @ 0x0000000014a4bc85 5. /build/src/Interpreters/ProcessList.cpp:520: DB::QueryStatus::throwProperExceptionIfNeeded(unsigned long const&, unsigned long const&) @ 0x0000000014a4bbd9 6. /build/src/Interpreters/ProcessList.cpp:557: DB::QueryStatus::checkTimeLimit() @ 0x0000000014a4c2cd 7. /build/src/Processors/Executors/PipelineExecutor.cpp:206: DB::PipelineExecutor::finalizeExecution() @ 0x00000000169b13ba 8. /build/src/Processors/Executors/PipelineExecutor.cpp:153: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x00000000169b0584 9. /build/src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:se190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169bfeab 10. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc3d92 11. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fcca080 12. ? @ 0x00007fbc6213eac3 13. ? @ 0x00007fbc621d0850 2025.07.28 12:02:36.438872 [ 5951 ] {0dbf2c83-d053-42d5-83b8-888915c2ddca} 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.6.10636.altinitytest (altinity build)) (from [::1]:56076) (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_5/optimize', 'r1') PARTITION BY toYYYYMM(date) ORDER BY date SETTINGS index_granularity = 9318, min_bytes_for_wide_part = 319533073, 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 = 193708779, compact_parts_max_granules_to_buffer = 1, compact_parts_merge_max_bytes_to_prefetch_part = 10307996, merge_max_block_size = 14206, old_parts_lifetime = 480., prefer_fetch_merged_part_size_threshold = 1, vertical_merge_algorithm_min_rows_to_activate = 377085, vertical_merge_algorithm_min_columns_to_activate = 100, min_merge_bytes_to_use_direct_io = 1, index_granularity_bytes = 4122060, 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 = true, enable_block_offset_column = false, cache_populated_by_fetch = true, marks_compress_block_size = 50401, primary_key_compress_block_size = 20311, 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. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000000a074fcb 4. /build/src/Databases/DatabaseReplicated.cpp:959: DB::DatabaseReplicated::checkTableEngine(DB::ASTCreateQuery const&, DB::ASTStorage&, std::shared_ptr) const @ 0x0000000013d9cf56 5. /build/src/Databases/DatabaseReplicated.cpp:1083: DB::DatabaseReplicated::checkQueryValid(std::shared_ptr const&, std::shared_ptr) const @ 0x0000000013d9ebb5 6. /build/src/Databases/DatabaseReplicated.cpp:1130: DB::DatabaseReplicated::tryEnqueueReplicatedDDL(std::shared_ptr const&, std::shared_ptr, DB::QueryFlags) @ 0x0000000013d9f10b 7. /build/src/Interpreters/InterpreterCreateQuery.cpp:1723: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000148f96f8 8. /build/src/Interpreters/InterpreterCreateQuery.cpp:2352: DB::InterpreterCreateQuery::execute() @ 0x0000000014905a41 9. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88dc9 10. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 11. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 12. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 13. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 14. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 16. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 17. ? @ 0x00007fbc6213eac3 18. ? @ 0x00007fbc621d0850 2025.07.28 12:02:36.453859 [ 17256 ] {559b8929-4658-49e0-b136-650dc9b4a54c} executeQuery: Code: 394. DB::Exception: Query was cancelled. (QUERY_WAS_CANCELLED) (version 25.3.6.10636.altinitytest (altinity build)) (from [::1]:55992) (comment: 02461_cancel_finish_race.sh) (query 1, line 1) (in query: KILL QUERY WHERE current_database = 'test_dtwle8fg' SYNC FORMAT Null), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000000a074fcb 4. /build/src/Interpreters/ProcessList.cpp:567: DB::QueryStatus::throwQueryWasCancelled() const @ 0x0000000014a4bc85 5. /build/src/Interpreters/ProcessList.cpp:520: DB::QueryStatus::throwProperExceptionIfNeeded(unsigned long const&, unsigned long const&) @ 0x0000000014a4bbd9 6. /build/src/Interpreters/ProcessList.cpp:557: DB::QueryStatus::checkTimeLimit() @ 0x0000000014a4c2cd 7. /build/src/Processors/Executors/PipelineExecutor.cpp:206: DB::PipelineExecutor::finalizeExecution() @ 0x00000000169b13ba 8. /build/src/Processors/Executors/PipelineExecutor.cpp:153: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x00000000169b0584 9. /build/src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:se190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169bfeab 10. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc3d92 11. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fcca080 12. ? @ 0x00007fbc6213eac3 13. ? @ 0x00007fbc621d0850 2025.07.28 12:02:36.456276 [ 62055 ] {} TCPHandler: Code: 394. DB::Exception: Query was cancelled. (QUERY_WAS_CANCELLED), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000000a074fcb 4. /build/src/Interpreters/ProcessList.cpp:567: DB::QueryStatus::throwQueryWasCancelled() const @ 0x0000000014a4bc85 5. /build/src/Interpreters/ProcessList.cpp:520: DB::QueryStatus::throwProperExceptionIfNeeded(unsigned long const&, unsigned long const&) @ 0x0000000014a4bbd9 6. /build/src/Interpreters/ProcessList.cpp:557: DB::QueryStatus::checkTimeLimit() @ 0x0000000014a4c2cd 7. /build/src/Processors/Executors/PipelineExecutor.cpp:206: DB::PipelineExecutor::finalizeExecution() @ 0x00000000169b13ba 8. /build/src/Processors/Executors/PipelineExecutor.cpp:153: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x00000000169b0584 9. /build/src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:se190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169bfeab 10. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc3d92 11. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fcca080 12. ? @ 0x00007fbc6213eac3 13. ? @ 0x00007fbc621d0850 Job's origin stack trace: 0. /build/src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000000fc33b84 1. /build/src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000000fcc2ea7 2. /build/src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fcc535c 3. /build/src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000000fcc584d 4. /build/src/Common/ThreadPool.h:279: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x00000000169bf193 5. /build/src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x00000000169bf518 6. /build/src/Server/TCPHandler.cpp:1237: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x00000000168f1525 7. /build/src/Server/TCPHandler.cpp:678: DB::TCPHandler::runImpl() @ 0x00000000168e68e5 8. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 9. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 10. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 11. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 12. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 13. ? @ 0x00007fbc6213eac3 14. ? @ 0x00007fbc621d0850 2025.07.28 12:02:36.484143 [ 17256 ] {} TCPHandler: Code: 394. DB::Exception: Query was cancelled. (QUERY_WAS_CANCELLED), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000000a074fcb 4. /build/src/Interpreters/ProcessList.cpp:567: DB::QueryStatus::throwQueryWasCancelled() const @ 0x0000000014a4bc85 5. /build/src/Interpreters/ProcessList.cpp:520: DB::QueryStatus::throwProperExceptionIfNeeded(unsigned long const&, unsigned long const&) @ 0x0000000014a4bbd9 6. /build/src/Interpreters/ProcessList.cpp:557: DB::QueryStatus::checkTimeLimit() @ 0x0000000014a4c2cd 7. /build/src/Processors/Executors/PipelineExecutor.cpp:206: DB::PipelineExecutor::finalizeExecution() @ 0x00000000169b13ba 8. /build/src/Processors/Executors/PipelineExecutor.cpp:153: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x00000000169b0584 9. /build/src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:se190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169bfeab 10. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc3d92 11. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fcca080 12. ? @ 0x00007fbc6213eac3 13. ? @ 0x00007fbc621d0850 Job's origin stack trace: 0. /build/src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000000fc33b84 1. /build/src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000000fcc2ea7 2. /build/src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fcc535c 3. /build/src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000000fcc584d 4. /build/src/Common/ThreadPool.h:279: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x00000000169bf193 5. /build/src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x00000000169bf518 6. /build/src/Server/TCPHandler.cpp:1237: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x00000000168f1525 7. /build/src/Server/TCPHandler.cpp:678: DB::TCPHandler::runImpl() @ 0x00000000168e68e5 8. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 9. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 10. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 11. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 12. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 13. ? @ 0x00007fbc6213eac3 14. ? @ 0x00007fbc621d0850 2025.07.28 12:02:36.484712 [ 5951 ] {} 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. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000000a074fcb 4. /build/src/Databases/DatabaseReplicated.cpp:959: DB::DatabaseReplicated::checkTableEngine(DB::ASTCreateQuery const&, DB::ASTStorage&, std::shared_ptr) const @ 0x0000000013d9cf56 5. /build/src/Databases/DatabaseReplicated.cpp:1083: DB::DatabaseReplicated::checkQueryValid(std::shared_ptr const&, std::shared_ptr) const @ 0x0000000013d9ebb5 6. /build/src/Databases/DatabaseReplicated.cpp:1130: DB::DatabaseReplicated::tryEnqueueReplicatedDDL(std::shared_ptr const&, std::shared_ptr, DB::QueryFlags) @ 0x0000000013d9f10b 7. /build/src/Interpreters/InterpreterCreateQuery.cpp:1723: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000148f96f8 8. /build/src/Interpreters/InterpreterCreateQuery.cpp:2352: DB::InterpreterCreateQuery::execute() @ 0x0000000014905a41 9. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88dc9 10. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 11. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 12. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 13. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 14. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 16. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 17. ? @ 0x00007fbc6213eac3 18. ? @ 0x00007fbc621d0850 2025.07.28 12:02:36.558849 [ 17252 ] {afa71117-980f-40db-bb0b-3f17e29f6d39} executeQuery: Code: 394. DB::Exception: Query was cancelled. (QUERY_WAS_CANCELLED) (version 25.3.6.10636.altinitytest (altinity build)) (from [::1]:56012) (comment: 02461_cancel_finish_race.sh) (query 1, line 1) (in query: KILL QUERY WHERE current_database = 'test_dtwle8fg' SYNC FORMAT Null), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000000a074fcb 4. /build/src/Interpreters/ProcessList.cpp:567: DB::QueryStatus::throwQueryWasCancelled() const @ 0x0000000014a4bc85 5. /build/src/Interpreters/ProcessList.cpp:520: DB::QueryStatus::throwProperExceptionIfNeeded(unsigned long const&, unsigned long const&) @ 0x0000000014a4bbd9 6. /build/src/Interpreters/ProcessList.cpp:557: DB::QueryStatus::checkTimeLimit() @ 0x0000000014a4c2cd 7. /build/src/Processors/Executors/PipelineExecutor.cpp:206: DB::PipelineExecutor::finalizeExecution() @ 0x00000000169b13ba 8. /build/src/Processors/Executors/PipelineExecutor.cpp:153: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x00000000169b0584 9. /build/src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:se190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169bfeab 10. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc3d92 11. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fcca080 12. ? @ 0x00007fbc6213eac3 13. ? @ 0x00007fbc621d0850 2025.07.28 12:02:36.570338 [ 17252 ] {} TCPHandler: Code: 394. DB::Exception: Query was cancelled. (QUERY_WAS_CANCELLED), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000000a074fcb 4. /build/src/Interpreters/ProcessList.cpp:567: DB::QueryStatus::throwQueryWasCancelled() const @ 0x0000000014a4bc85 5. /build/src/Interpreters/ProcessList.cpp:520: DB::QueryStatus::throwProperExceptionIfNeeded(unsigned long const&, unsigned long const&) @ 0x0000000014a4bbd9 6. /build/src/Interpreters/ProcessList.cpp:557: DB::QueryStatus::checkTimeLimit() @ 0x0000000014a4c2cd 7. /build/src/Processors/Executors/PipelineExecutor.cpp:206: DB::PipelineExecutor::finalizeExecution() @ 0x00000000169b13ba 8. /build/src/Processors/Executors/PipelineExecutor.cpp:153: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x00000000169b0584 9. /build/src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:se190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169bfeab 10. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc3d92 11. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fcca080 12. ? @ 0x00007fbc6213eac3 13. ? @ 0x00007fbc621d0850 Job's origin stack trace: 0. /build/src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000000fc33b84 1. /build/src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000000fcc2ea7 2. /build/src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fcc535c 3. /build/src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000000fcc584d 4. /build/src/Common/ThreadPool.h:279: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x00000000169bf193 5. /build/src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x00000000169bf518 6. /build/src/Server/TCPHandler.cpp:1237: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x00000000168f1525 7. /build/src/Server/TCPHandler.cpp:678: DB::TCPHandler::runImpl() @ 0x00000000168e68e5 8. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 9. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 10. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 11. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 12. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 13. ? @ 0x00007fbc6213eac3 14. ? @ 0x00007fbc621d0850 2025.07.28 12:02:36.588745 [ 62065 ] {} TCPHandler: Code: 394. DB::Exception: Query was cancelled. (QUERY_WAS_CANCELLED), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000000a074fcb 4. /build/src/Interpreters/ProcessList.cpp:567: DB::QueryStatus::throwQueryWasCancelled() const @ 0x0000000014a4bc85 5. /build/src/Interpreters/ProcessList.cpp:520: DB::QueryStatus::throwProperExceptionIfNeeded(unsigned long const&, unsigned long const&) @ 0x0000000014a4bbd9 6. /build/src/Interpreters/ProcessList.cpp:531: DB::QueryStatus::addPipelineExecutor(DB::PipelineExecutor*) @ 0x0000000014a4bd9c 7. /build/src/Processors/Executors/PipelineExecutor.cpp:73: DB::PipelineExecutor::PipelineExecutor(std::shared_ptr, std::allocator>>>&, std::shared_ptr) @ 0x00000000169afe31 8. /build/contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x00000000169c07b5 9. /build/src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x00000000169c0978 10. /build/src/Interpreters/InterpreterKillQueryQuery.cpp:439: DB::InterpreterKillQueryQuery::getSelectResult(String const&, String const&) @ 0x0000000014cf0f04 11. /build/src/Interpreters/InterpreterKillQueryQuery.cpp:222: DB::InterpreterKillQueryQuery::execute() @ 0x0000000014cebde2 12. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88dc9 13. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 14. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 15. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 16. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 17. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 18. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 19. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 20. ? @ 0x00007fbc6213eac3 21. ? @ 0x00007fbc621d0850 2025.07.28 12:02:36.643731 [ 4446 ] {762a8d4f-8dc3-452a-a0cd-0b394e89fd42} executeQuery: Code: 394. DB::Exception: Query was cancelled. (QUERY_WAS_CANCELLED) (version 25.3.6.10636.altinitytest (altinity build)) (from [::1]:55998) (comment: 02461_cancel_finish_race.sh) (query 1, line 1) (in query: KILL QUERY WHERE current_database = 'test_dtwle8fg' SYNC FORMAT Null), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000000a074fcb 4. /build/src/Interpreters/ProcessList.cpp:567: DB::QueryStatus::throwQueryWasCancelled() const @ 0x0000000014a4bc85 5. /build/src/Interpreters/ProcessList.cpp:520: DB::QueryStatus::throwProperExceptionIfNeeded(unsigned long const&, unsigned long const&) @ 0x0000000014a4bbd9 6. /build/src/Interpreters/ProcessList.cpp:557: DB::QueryStatus::checkTimeLimit() @ 0x0000000014a4c2cd 7. /build/src/Processors/Executors/PipelineExecutor.cpp:206: DB::PipelineExecutor::finalizeExecution() @ 0x00000000169b13ba 8. /build/src/Processors/Executors/PipelineExecutor.cpp:153: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x00000000169b0584 9. /build/src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:se190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169bfeab 10. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc3d92 11. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fcca080 12. ? @ 0x00007fbc6213eac3 13. ? @ 0x00007fbc621d0850 2025.07.28 12:02:36.663557 [ 62057 ] {} TCPHandler: Code: 394. DB::Exception: Query was cancelled. (QUERY_WAS_CANCELLED), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000000a074fcb 4. /build/src/Interpreters/ProcessList.cpp:567: DB::QueryStatus::throwQueryWasCancelled() const @ 0x0000000014a4bc85 5. /build/src/Interpreters/ProcessList.cpp:520: DB::QueryStatus::throwProperExceptionIfNeeded(unsigned long const&, unsigned long const&) @ 0x0000000014a4bbd9 6. /build/src/Interpreters/ProcessList.cpp:531: DB::QueryStatus::addPipelineExecutor(DB::PipelineExecutor*) @ 0x0000000014a4bd9c 7. /build/src/Processors/Executors/PipelineExecutor.cpp:73: DB::PipelineExecutor::PipelineExecutor(std::shared_ptr, std::allocator>>>&, std::shared_ptr) @ 0x00000000169afe31 8. /build/contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x00000000169c07b5 9. /build/src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x00000000169c0978 10. /build/src/Interpreters/InterpreterKillQueryQuery.cpp:439: DB::InterpreterKillQueryQuery::getSelectResult(String const&, String const&) @ 0x0000000014cf0f04 11. /build/src/Interpreters/InterpreterKillQueryQuery.cpp:222: DB::InterpreterKillQueryQuery::execute() @ 0x0000000014cebde2 12. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88dc9 13. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 14. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 15. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 16. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 17. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 18. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 19. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 20. ? @ 0x00007fbc6213eac3 21. ? @ 0x00007fbc621d0850 2025.07.28 12:02:36.669938 [ 4446 ] {} TCPHandler: Code: 394. DB::Exception: Query was cancelled. (QUERY_WAS_CANCELLED), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000000a074fcb 4. /build/src/Interpreters/ProcessList.cpp:567: DB::QueryStatus::throwQueryWasCancelled() const @ 0x0000000014a4bc85 5. /build/src/Interpreters/ProcessList.cpp:520: DB::QueryStatus::throwProperExceptionIfNeeded(unsigned long const&, unsigned long const&) @ 0x0000000014a4bbd9 6. /build/src/Interpreters/ProcessList.cpp:557: DB::QueryStatus::checkTimeLimit() @ 0x0000000014a4c2cd 7. /build/src/Processors/Executors/PipelineExecutor.cpp:206: DB::PipelineExecutor::finalizeExecution() @ 0x00000000169b13ba 8. /build/src/Processors/Executors/PipelineExecutor.cpp:153: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x00000000169b0584 9. /build/src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:se190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169bfeab 10. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc3d92 11. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fcca080 12. ? @ 0x00007fbc6213eac3 13. ? @ 0x00007fbc621d0850 Job's origin stack trace: 0. /build/src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000000fc33b84 1. /build/src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000000fcc2ea7 2. /build/src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fcc535c 3. /build/src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000000fcc584d 4. /build/src/Common/ThreadPool.h:279: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x00000000169bf193 5. /build/src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x00000000169bf518 6. /build/src/Server/TCPHandler.cpp:1237: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x00000000168f1525 7. /build/src/Server/TCPHandler.cpp:678: DB::TCPHandler::runImpl() @ 0x00000000168e68e5 8. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 9. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 10. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 11. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 12. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 13. ? @ 0x00007fbc6213eac3 14. ? @ 0x00007fbc621d0850 2025.07.28 12:02:36.718915 [ 62314 ] {} TCPHandler: Code: 394. DB::Exception: Query was cancelled. (QUERY_WAS_CANCELLED), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000000a074fcb 4. /build/src/Interpreters/ProcessList.cpp:567: DB::QueryStatus::throwQueryWasCancelled() const @ 0x0000000014a4bc85 5. /build/src/Interpreters/ProcessList.cpp:520: DB::QueryStatus::throwProperExceptionIfNeeded(unsigned long const&, unsigned long const&) @ 0x0000000014a4bbd9 6. /build/src/Interpreters/ProcessList.cpp:557: DB::QueryStatus::checkTimeLimit() @ 0x0000000014a4c2cd 7. /build/src/Processors/Executors/PipelineExecutor.cpp:206: DB::PipelineExecutor::finalizeExecution() @ 0x00000000169b13ba 8. /build/src/Processors/Executors/PipelineExecutor.cpp:181: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x00000000169b1726 9. /build/src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x00000000169c081c 10. /build/src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x00000000169c0978 11. /build/src/Interpreters/InterpreterKillQueryQuery.cpp:442: DB::InterpreterKillQueryQuery::getSelectResult(String const&, String const&) @ 0x0000000014cf0f6b 12. /build/src/Interpreters/InterpreterKillQueryQuery.cpp:222: DB::InterpreterKillQueryQuery::execute() @ 0x0000000014cebde2 13. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88dc9 14. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 15. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 16. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 17. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 18. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 19. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 20. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 21. ? @ 0x00007fbc6213eac3 22. ? @ 0x00007fbc621d0850 2025.07.28 12:02:37.189840 [ 62055 ] {741a3709-d1fc-4ff1-9a90-43c7da89e6ae} executeQuery: Code: 394. DB::Exception: Query was cancelled. (QUERY_WAS_CANCELLED) (version 25.3.6.10636.altinitytest (altinity build)) (from [::1]:56174) (comment: 02461_cancel_finish_race.sh) (query 1, line 1) (in query: KILL QUERY WHERE current_database = 'test_dtwle8fg' SYNC FORMAT Null), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000000a074fcb 4. /build/src/Interpreters/ProcessList.cpp:567: DB::QueryStatus::throwQueryWasCancelled() const @ 0x0000000014a4bc85 5. /build/src/Interpreters/ProcessList.cpp:520: DB::QueryStatus::throwProperExceptionIfNeeded(unsigned long const&, unsigned long const&) @ 0x0000000014a4bbd9 6. /build/src/Interpreters/ProcessList.cpp:531: DB::QueryStatus::addPipelineExecutor(DB::PipelineExecutor*) @ 0x0000000014a4bd9c 7. /build/src/Processors/Executors/PipelineExecutor.cpp:73: DB::PipelineExecutor::PipelineExecutor(std::shared_ptr, std::allocator>>>&, std::shared_ptr) @ 0x00000000169afe31 8. /build/contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x00000000169bef66 9. /build/src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x00000000169bf518 10. /build/src/Server/TCPHandler.cpp:1237: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x00000000168f1525 11. /build/src/Server/TCPHandler.cpp:678: DB::TCPHandler::runImpl() @ 0x00000000168e68e5 12. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 13. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 14. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 16. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 17. ? @ 0x00007fbc6213eac3 18. ? @ 0x00007fbc621d0850 2025.07.28 12:02:37.259055 [ 17371 ] {} TCPHandler: Code: 394. DB::Exception: Query was cancelled. (QUERY_WAS_CANCELLED), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000000a074fcb 4. /build/src/Interpreters/ProcessList.cpp:567: DB::QueryStatus::throwQueryWasCancelled() const @ 0x0000000014a4bc85 5. /build/src/Interpreters/ProcessList.cpp:520: DB::QueryStatus::throwProperExceptionIfNeeded(unsigned long const&, unsigned long const&) @ 0x0000000014a4bbd9 6. /build/src/Interpreters/ProcessList.cpp:531: DB::QueryStatus::addPipelineExecutor(DB::PipelineExecutor*) @ 0x0000000014a4bd9c 7. /build/src/Processors/Executors/PipelineExecutor.cpp:73: DB::PipelineExecutor::PipelineExecutor(std::shared_ptr, std::allocator>>>&, std::shared_ptr) @ 0x00000000169afe31 8. /build/contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x00000000169c07b5 9. /build/src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x00000000169c0978 10. /build/src/Interpreters/InterpreterKillQueryQuery.cpp:439: DB::InterpreterKillQueryQuery::getSelectResult(String const&, String const&) @ 0x0000000014cf0f04 11. /build/src/Interpreters/InterpreterKillQueryQuery.cpp:222: DB::InterpreterKillQueryQuery::execute() @ 0x0000000014cebde2 12. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88dc9 13. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 14. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 15. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 16. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 17. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 18. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 19. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 20. ? @ 0x00007fbc6213eac3 21. ? @ 0x00007fbc621d0850 2025.07.28 12:02:37.276274 [ 11826 ] {c125228c-a098-4e9d-9df6-000fc2e74a71} executeQuery: Code: 701. DB::Exception: Reading in parallel from replicas is enabled but cluster to execute query is not provided. Please set 'cluster_for_parallel_replicas' setting. (CLUSTER_DOESNT_EXIST) (version 25.3.6.10636.altinitytest (altinity build)) (from [::1]:55904) (comment: 02935_parallel_replicas_settings.sql) (query 7, line 9) (in query: SELECT count() FROM test_parallel_replicas_settings WHERE NOT ignore(*);), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000000a074fcb 4. /build/src/Interpreters/Context.cpp:6297: DB::Context::getClusterForParallelReplicas() const @ 0x0000000014451291 5. /build/src/Interpreters/ClusterProxy/executeQuery.cpp:823: DB::ClusterProxy::canUseParallelReplicasOnInitiator(std::shared_ptr const&) @ 0x00000000158b28c6 6. /build/src/Planner/PlannerJoinTree.cpp:1012: DB::(anonymous namespace)::buildQueryPlanForTableExpression(std::shared_ptr, std::shared_ptr const&, DB::SelectQueryInfo const&, DB::SelectQueryOptions const&, std::shared_ptr&, bool, bool) @ 0x0000000014997182 7. /build/src/Planner/PlannerJoinTree.cpp:2252: DB::buildJoinTreeQueryPlan(std::shared_ptr const&, DB::SelectQueryInfo const&, DB::SelectQueryOptions&, std::unordered_set, std::equal_to, std::allocator> const&, std::shared_ptr&) @ 0x000000001498e109 8. /build/src/Planner/Planner.cpp:1553: DB::Planner::buildPlanForQueryNode() @ 0x0000000014979dae 9. /build/src/Planner/Planner.cpp:1308: DB::Planner::buildQueryPlanIfNeeded() @ 0x000000001497685c 10. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:255: DB::InterpreterSelectQueryAnalyzer::getQueryPlan() @ 0x000000001497476d 11. /build/src/Interpreters/executeQuery.cpp:1405: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88806 12. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 13. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 14. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 15. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 16. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 17. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 18. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 19. ? @ 0x00007fbc6213eac3 20. ? @ 0x00007fbc621d0850 2025.07.28 12:02:37.277795 [ 5112 ] {54ebce24-293e-4d9c-b05a-cfea68ea474e} executeQuery: Code: 394. DB::Exception: Query was cancelled. (QUERY_WAS_CANCELLED) (version 25.3.6.10636.altinitytest (altinity build)) (from [::1]:56192) (comment: 02461_cancel_finish_race.sh) (query 1, line 1) (in query: KILL QUERY WHERE current_database = 'test_dtwle8fg' SYNC FORMAT Null), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000000a074fcb 4. /build/src/Interpreters/ProcessList.cpp:567: DB::QueryStatus::throwQueryWasCancelled() const @ 0x0000000014a4bc85 5. /build/src/Interpreters/ProcessList.cpp:520: DB::QueryStatus::throwProperExceptionIfNeeded(unsigned long const&, unsigned long const&) @ 0x0000000014a4bbd9 6. /build/src/Interpreters/ProcessList.cpp:557: DB::QueryStatus::checkTimeLimit() @ 0x0000000014a4c2cd 7. /build/src/Processors/Executors/PipelineExecutor.cpp:206: DB::PipelineExecutor::finalizeExecution() @ 0x00000000169b13ba 8. /build/src/Processors/Executors/PipelineExecutor.cpp:153: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x00000000169b0584 9. /build/src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:se190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169bfeab 10. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc3d92 11. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fcca080 12. ? @ 0x00007fbc6213eac3 13. ? @ 0x00007fbc621d0850 2025.07.28 12:02:37.280072 [ 11826 ] {} TCPHandler: Code: 701. DB::Exception: Reading in parallel from replicas is enabled but cluster to execute query is not provided. Please set 'cluster_for_parallel_replicas' setting. (CLUSTER_DOESNT_EXIST), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000000a074fcb 4. /build/src/Interpreters/Context.cpp:6297: DB::Context::getClusterForParallelReplicas() const @ 0x0000000014451291 5. /build/src/Interpreters/ClusterProxy/executeQuery.cpp:823: DB::ClusterProxy::canUseParallelReplicasOnInitiator(std::shared_ptr const&) @ 0x00000000158b28c6 6. /build/src/Planner/PlannerJoinTree.cpp:1012: DB::(anonymous namespace)::buildQueryPlanForTableExpression(std::shared_ptr, std::shared_ptr const&, DB::SelectQueryInfo const&, DB::SelectQueryOptions const&, std::shared_ptr&, bool, bool) @ 0x0000000014997182 7. /build/src/Planner/PlannerJoinTree.cpp:2252: DB::buildJoinTreeQueryPlan(std::shared_ptr const&, DB::SelectQueryInfo const&, DB::SelectQueryOptions&, std::unordered_set, std::equal_to, std::allocator> const&, std::shared_ptr&) @ 0x000000001498e109 8. /build/src/Planner/Planner.cpp:1553: DB::Planner::buildPlanForQueryNode() @ 0x0000000014979dae 9. /build/src/Planner/Planner.cpp:1308: DB::Planner::buildQueryPlanIfNeeded() @ 0x000000001497685c 10. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:255: DB::InterpreterSelectQueryAnalyzer::getQueryPlan() @ 0x000000001497476d 11. /build/src/Interpreters/executeQuery.cpp:1405: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88806 12. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 13. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 14. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 15. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 16. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 17. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 18. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 19. ? @ 0x00007fbc6213eac3 20. ? @ 0x00007fbc621d0850 2025.07.28 12:02:37.300083 [ 5112 ] {} TCPHandler: Code: 394. DB::Exception: Query was cancelled. (QUERY_WAS_CANCELLED), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000000a074fcb 4. /build/src/Interpreters/ProcessList.cpp:567: DB::QueryStatus::throwQueryWasCancelled() const @ 0x0000000014a4bc85 5. /build/src/Interpreters/ProcessList.cpp:520: DB::QueryStatus::throwProperExceptionIfNeeded(unsigned long const&, unsigned long const&) @ 0x0000000014a4bbd9 6. /build/src/Interpreters/ProcessList.cpp:557: DB::QueryStatus::checkTimeLimit() @ 0x0000000014a4c2cd 7. /build/src/Processors/Executors/PipelineExecutor.cpp:206: DB::PipelineExecutor::finalizeExecution() @ 0x00000000169b13ba 8. /build/src/Processors/Executors/PipelineExecutor.cpp:153: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x00000000169b0584 9. /build/src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:se190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169bfeab 10. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc3d92 11. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fcca080 12. ? @ 0x00007fbc6213eac3 13. ? @ 0x00007fbc621d0850 Job's origin stack trace: 0. /build/src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000000fc33b84 1. /build/src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000000fcc2ea7 2. /build/src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fcc535c 3. /build/src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000000fcc584d 4. /build/src/Common/ThreadPool.h:279: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x00000000169bf193 5. /build/src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x00000000169bf518 6. /build/src/Server/TCPHandler.cpp:1237: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x00000000168f1525 7. /build/src/Server/TCPHandler.cpp:678: DB::TCPHandler::runImpl() @ 0x00000000168e68e5 8. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 9. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 10. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 11. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 12. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 13. ? @ 0x00007fbc6213eac3 14. ? @ 0x00007fbc621d0850 2025.07.28 12:02:37.300290 [ 17252 ] {87bc4d32-628b-4f3d-a6bd-a418122cefdd} executeQuery: Code: 394. DB::Exception: Query was cancelled. (QUERY_WAS_CANCELLED) (version 25.3.6.10636.altinitytest (altinity build)) (from [::1]:56220) (comment: 02461_cancel_finish_race.sh) (query 1, line 1) (in query: KILL QUERY WHERE current_database = 'test_dtwle8fg' SYNC FORMAT Null), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000000a074fcb 4. /build/src/Interpreters/ProcessList.cpp:567: DB::QueryStatus::throwQueryWasCancelled() const @ 0x0000000014a4bc85 5. /build/src/Interpreters/ProcessList.cpp:520: DB::QueryStatus::throwProperExceptionIfNeeded(unsigned long const&, unsigned long const&) @ 0x0000000014a4bbd9 6. /build/src/Interpreters/ProcessList.cpp:557: DB::QueryStatus::checkTimeLimit() @ 0x0000000014a4c2cd 7. /build/src/Processors/Executors/PipelineExecutor.cpp:206: DB::PipelineExecutor::finalizeExecution() @ 0x00000000169b13ba 8. /build/src/Processors/Executors/PipelineExecutor.cpp:153: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x00000000169b0584 9. /build/src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:se190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169bfeab 10. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc3d92 11. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fcca080 12. ? @ 0x00007fbc6213eac3 13. ? @ 0x00007fbc621d0850 2025.07.28 12:02:37.322307 [ 17252 ] {} TCPHandler: Code: 394. DB::Exception: Query was cancelled. (QUERY_WAS_CANCELLED), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000000a074fcb 4. /build/src/Interpreters/ProcessList.cpp:567: DB::QueryStatus::throwQueryWasCancelled() const @ 0x0000000014a4bc85 5. /build/src/Interpreters/ProcessList.cpp:520: DB::QueryStatus::throwProperExceptionIfNeeded(unsigned long const&, unsigned long const&) @ 0x0000000014a4bbd9 6. /build/src/Interpreters/ProcessList.cpp:557: DB::QueryStatus::checkTimeLimit() @ 0x0000000014a4c2cd 7. /build/src/Processors/Executors/PipelineExecutor.cpp:206: DB::PipelineExecutor::finalizeExecution() @ 0x00000000169b13ba 8. /build/src/Processors/Executors/PipelineExecutor.cpp:153: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x00000000169b0584 9. /build/src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:se190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169bfeab 10. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc3d92 11. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fcca080 12. ? @ 0x00007fbc6213eac3 13. ? @ 0x00007fbc621d0850 Job's origin stack trace: 0. /build/src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000000fc33b84 1. /build/src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000000fcc2ea7 2. /build/src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fcc535c 3. /build/src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000000fcc584d 4. /build/src/Common/ThreadPool.h:279: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x00000000169bf193 5. /build/src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x00000000169bf518 6. /build/src/Server/TCPHandler.cpp:1237: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x00000000168f1525 7. /build/src/Server/TCPHandler.cpp:678: DB::TCPHandler::runImpl() @ 0x00000000168e68e5 8. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 9. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 10. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 11. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 12. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 13. ? @ 0x00007fbc6213eac3 14. ? @ 0x00007fbc621d0850 2025.07.28 12:02:37.323952 [ 62055 ] {} TCPHandler: Code: 394. DB::Exception: Query was cancelled. (QUERY_WAS_CANCELLED), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000000a074fcb 4. /build/src/Interpreters/ProcessList.cpp:567: DB::QueryStatus::throwQueryWasCancelled() const @ 0x0000000014a4bc85 5. /build/src/Interpreters/ProcessList.cpp:520: DB::QueryStatus::throwProperExceptionIfNeeded(unsigned long const&, unsigned long const&) @ 0x0000000014a4bbd9 6. /build/src/Interpreters/ProcessList.cpp:531: DB::QueryStatus::addPipelineExecutor(DB::PipelineExecutor*) @ 0x0000000014a4bd9c 7. /build/src/Processors/Executors/PipelineExecutor.cpp:73: DB::PipelineExecutor::PipelineExecutor(std::shared_ptr, std::allocator>>>&, std::shared_ptr) @ 0x00000000169afe31 8. /build/contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x00000000169bef66 9. /build/src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x00000000169bf518 10. /build/src/Server/TCPHandler.cpp:1237: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x00000000168f1525 11. /build/src/Server/TCPHandler.cpp:678: DB::TCPHandler::runImpl() @ 0x00000000168e68e5 12. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 13. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 14. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 16. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 17. ? @ 0x00007fbc6213eac3 18. ? @ 0x00007fbc621d0850 2025.07.28 12:02:37.379957 [ 62093 ] {} TCPHandler: TCPHandler: Code: 210. DB::NetException: Connection reset by peer, while reading from socket (peer: [::1]:56382, local: [::1]:9000). (NETWORK_ERROR), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::NetException::NetException(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&) @ 0x000000000fd50fb5 3. /build/src/IO/ReadBufferFromPocoSocket.cpp:83: DB::ReadBufferFromPocoSocketBase::socketReceiveBytesImpl(char*, unsigned long) @ 0x000000000fd5052e 4. /build/src/IO/ReadBufferFromPocoSocket.cpp:107: DB::ReadBufferFromPocoSocketBase::nextImpl() @ 0x000000000fd50a63 5. /build/src/IO/ReadBuffer.h:60: DB::ReadBuffer::next() @ 0x000000000a148c7b 6. /build/src/IO/ReadBuffer.h:96: DB::TCPHandler::runImpl() @ 0x00000000168e5e5e 7. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 8. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 9. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 10. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 11. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 12. ? @ 0x00007fbc6213eac3 13. ? @ 0x00007fbc621d0850 (version 25.3.6.10636.altinitytest (altinity build)) 2025.07.28 12:02:37.381626 [ 3967 ] {} test_13.rmt2 (7f9b740d-015c-470e-8cc6-8ba33be0dc63): auto DB::StorageReplicatedMergeTree::processQueueEntry(ReplicatedMergeTreeQueue::SelectedEntryPtr)::(anonymous class)::operator()(LogEntryPtr &) const: Code: 86. DB::HTTPException: Received error from remote server http://146b4357c08d:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Ftest%2F01165%2Ftest_13%2Frmt%2Freplicas%2F1&part=20250728_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.6.10636.altinitytest (altinity build)) '. (RECEIVED_ERROR_FROM_REMOTE_IO_SERVER), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.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 const&, int&&, String const&, unsigned long&&, String const&) @ 0x000000000feda8d9 4. /build/src/IO/HTTPCommon.cpp:104: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x000000000feda6e2 5. /build/src/IO/HTTPCommon.cpp:93: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x000000000feda537 6. /build/src/IO/ReadWriteBufferFromHTTP.cpp:277: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x000000001184a4c4 7. /build/src/IO/ReadWriteBufferFromHTTP.cpp:285: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x000000001184a615 8. /build/src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x000000001184ae59 9. /build/src/IO/ReadWriteBufferFromHTTP.cpp:472: void std::__function::__policy_invoker::__call_impl[abi:se190107]>(std::__function::__policy_storage const*) @ 0x000000001184cedd 10. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001184858b 11. /build/src/IO/ReadWriteBufferFromHTTP.cpp:465: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x000000001184bf0b 12. /build/src/IO/ReadBuffer.h:60: DB::ReadBuffer::next() @ 0x000000000a148c7b 13. /build/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) @ 0x0000000011849fb2 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]>&)>&, 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&) @ 0x0000000011841980 15. /build/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) @ 0x000000001621208e 16. /build/src/Storages/StorageReplicatedMergeTree.cpp:5228: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl[abi:se190107] const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000015f9a5fe 17. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000015ed8bfd 18. /build/src/Storages/StorageReplicatedMergeTree.cpp:2514: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x0000000015ec9aab 19. /build/src/Storages/StorageReplicatedMergeTree.cpp:2349: DB::StorageReplicatedMergeTree::executeLogEntry(DB::ReplicatedMergeTreeLogEntry&) @ 0x0000000015eba91b 20. /build/src/Storages/StorageReplicatedMergeTree.cpp:3876: bool std::__function::__policy_invoker&)>::__call_impl[abi:se190107])::$_1, bool (std::shared_ptr&)>>(std::__function::__policy_storage const*, std::shared_ptr&) @ 0x0000000015f9837e 21. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000165d6fc3 22. /build/src/Storages/StorageReplicatedMergeTree.cpp:3872: DB::StorageReplicatedMergeTree::processQueueEntry(std::shared_ptr) @ 0x0000000015efc18a 23. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001624c1b2 24. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000162f9c70 25. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x00000000162fa55a 26. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc6653 27. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000000fccc4c3 28. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc3d92 29. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fcca080 30. ? @ 0x00007fbc6213eac3 31. ? @ 0x00007fbc621d0850 (version 25.3.6.10636.altinitytest (altinity build)) 2025.07.28 12:02:37.381764 [ 62093 ] {} ServerErrorHandler: Code: 210. DB::NetException: Connection reset by peer, while reading from socket (peer: [::1]:56382, local: [::1]:9000). (NETWORK_ERROR), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::NetException::NetException(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&) @ 0x000000000fd50fb5 3. /build/src/IO/ReadBufferFromPocoSocket.cpp:83: DB::ReadBufferFromPocoSocketBase::socketReceiveBytesImpl(char*, unsigned long) @ 0x000000000fd5052e 4. /build/src/IO/ReadBufferFromPocoSocket.cpp:107: DB::ReadBufferFromPocoSocketBase::nextImpl() @ 0x000000000fd50a63 5. /build/src/IO/ReadBuffer.h:60: DB::ReadBuffer::next() @ 0x000000000a148c7b 6. /build/src/IO/ReadBuffer.h:96: DB::TCPHandler::runImpl() @ 0x00000000168e5e5e 7. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 8. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 9. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 10. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 11. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 12. ? @ 0x00007fbc6213eac3 13. ? @ 0x00007fbc621d0850 (version 25.3.6.10636.altinitytest (altinity build)) 2025.07.28 12:02:37.383256 [ 62065 ] {e46a3cd0-26e7-47bd-b189-61d0cf5676af} executeQuery: Code: 394. DB::Exception: Query was cancelled. (QUERY_WAS_CANCELLED) (version 25.3.6.10636.altinitytest (altinity build)) (from [::1]:56230) (comment: 02461_cancel_finish_race.sh) (query 1, line 1) (in query: KILL QUERY WHERE current_database = 'test_dtwle8fg' SYNC FORMAT Null), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000000a074fcb 4. /build/src/Interpreters/ProcessList.cpp:567: DB::QueryStatus::throwQueryWasCancelled() const @ 0x0000000014a4bc85 5. /build/src/Interpreters/ProcessList.cpp:520: DB::QueryStatus::throwProperExceptionIfNeeded(unsigned long const&, unsigned long const&) @ 0x0000000014a4bbd9 6. /build/src/Interpreters/ProcessList.cpp:557: DB::QueryStatus::checkTimeLimit() @ 0x0000000014a4c2cd 7. /build/src/Processors/Executors/PipelineExecutor.cpp:206: DB::PipelineExecutor::finalizeExecution() @ 0x00000000169b13ba 8. /build/src/Processors/Executors/PipelineExecutor.cpp:153: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x00000000169b0584 9. /build/src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:se190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169bfeab 10. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc3d92 11. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fcca080 12. ? @ 0x00007fbc6213eac3 13. ? @ 0x00007fbc621d0850 2025.07.28 12:02:37.385517 [ 62065 ] {e46a3cd0-26e7-47bd-b189-61d0cf5676af} 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]:56230). (NETWORK_ERROR), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::NetException::NetException(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&) @ 0x000000000fd50fb5 3. /build/src/IO/WriteBufferFromPocoSocket.cpp:171: DB::WriteBufferFromPocoSocket::nextImpl() @ 0x000000000fd525a7 4. /build/src/IO/WriteBuffer.h:53: DB::WriteBuffer::next() @ 0x000000000a0755be 5. /build/src/Server/TCPHandler.cpp:826: DB::TCPHandler::runImpl() @ 0x00000000168e6c9c 6. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 7. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 8. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 9. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 10. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 11. ? @ 0x00007fbc6213eac3 12. ? @ 0x00007fbc621d0850 (version 25.3.6.10636.altinitytest (altinity build)) 2025.07.28 12:02:37.388690 [ 62065 ] {} TCPHandler: Code: 394. DB::Exception: Query was cancelled. (QUERY_WAS_CANCELLED), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000000a074fcb 4. /build/src/Interpreters/ProcessList.cpp:567: DB::QueryStatus::throwQueryWasCancelled() const @ 0x0000000014a4bc85 5. /build/src/Interpreters/ProcessList.cpp:520: DB::QueryStatus::throwProperExceptionIfNeeded(unsigned long const&, unsigned long const&) @ 0x0000000014a4bbd9 6. /build/src/Interpreters/ProcessList.cpp:557: DB::QueryStatus::checkTimeLimit() @ 0x0000000014a4c2cd 7. /build/src/Processors/Executors/PipelineExecutor.cpp:206: DB::PipelineExecutor::finalizeExecution() @ 0x00000000169b13ba 8. /build/src/Processors/Executors/PipelineExecutor.cpp:153: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x00000000169b0584 9. /build/src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:se190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169bfeab 10. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc3d92 11. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fcca080 12. ? @ 0x00007fbc6213eac3 13. ? @ 0x00007fbc621d0850 Job's origin stack trace: 0. /build/src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000000fc33b84 1. /build/src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000000fcc2ea7 2. /build/src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fcc535c 3. /build/src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000000fcc584d 4. /build/src/Common/ThreadPool.h:279: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x00000000169bf193 5. /build/src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x00000000169bf518 6. /build/src/Server/TCPHandler.cpp:1237: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x00000000168f1525 7. /build/src/Server/TCPHandler.cpp:678: DB::TCPHandler::runImpl() @ 0x00000000168e68e5 8. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 9. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 10. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 11. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 12. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 13. ? @ 0x00007fbc6213eac3 14. ? @ 0x00007fbc621d0850 2025.07.28 12:02:37.393519 [ 4900 ] {} TCPHandler: Code: 394. DB::Exception: Query was cancelled. (QUERY_WAS_CANCELLED), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000000a074fcb 4. /build/src/Interpreters/ProcessList.cpp:567: DB::QueryStatus::throwQueryWasCancelled() const @ 0x0000000014a4bc85 5. /build/src/Interpreters/ProcessList.cpp:520: DB::QueryStatus::throwProperExceptionIfNeeded(unsigned long const&, unsigned long const&) @ 0x0000000014a4bbd9 6. /build/src/Interpreters/ProcessList.cpp:557: DB::QueryStatus::checkTimeLimit() @ 0x0000000014a4c2cd 7. /build/src/Processors/Executors/PipelineExecutor.cpp:206: DB::PipelineExecutor::finalizeExecution() @ 0x00000000169b13ba 8. /build/src/Processors/Executors/PipelineExecutor.cpp:181: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x00000000169b1726 9. /build/src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x00000000169c081c 10. /build/src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x00000000169c0978 11. /build/src/Interpreters/InterpreterKillQueryQuery.cpp:439: DB::InterpreterKillQueryQuery::getSelectResult(String const&, String const&) @ 0x0000000014cf0f04 12. /build/src/Interpreters/InterpreterKillQueryQuery.cpp:222: DB::InterpreterKillQueryQuery::execute() @ 0x0000000014cebde2 13. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88dc9 14. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 15. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 16. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 17. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 18. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 19. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 20. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 21. ? @ 0x00007fbc6213eac3 22. ? @ 0x00007fbc621d0850 2025.07.28 12:02:37.396870 [ 4446 ] {164ed7f1-354e-4742-aafc-c88df5c51a57} executeQuery: Code: 394. DB::Exception: Query was cancelled. (QUERY_WAS_CANCELLED) (version 25.3.6.10636.altinitytest (altinity build)) (from [::1]:56240) (comment: 02461_cancel_finish_race.sh) (query 1, line 1) (in query: KILL QUERY WHERE current_database = 'test_dtwle8fg' SYNC FORMAT Null), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000000a074fcb 4. /build/src/Interpreters/ProcessList.cpp:567: DB::QueryStatus::throwQueryWasCancelled() const @ 0x0000000014a4bc85 5. /build/src/Interpreters/ProcessList.cpp:520: DB::QueryStatus::throwProperExceptionIfNeeded(unsigned long const&, unsigned long const&) @ 0x0000000014a4bbd9 6. /build/src/Interpreters/ProcessList.cpp:557: DB::QueryStatus::checkTimeLimit() @ 0x0000000014a4c2cd 7. /build/src/Processors/Executors/PipelineExecutor.cpp:206: DB::PipelineExecutor::finalizeExecution() @ 0x00000000169b13ba 8. /build/src/Processors/Executors/PipelineExecutor.cpp:153: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x00000000169b0584 9. /build/src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:se190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169bfeab 10. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc3d92 11. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fcca080 12. ? @ 0x00007fbc6213eac3 13. ? @ 0x00007fbc621d0850 2025.07.28 12:02:37.399748 [ 4446 ] {164ed7f1-354e-4742-aafc-c88df5c51a57} 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]:56240). (NETWORK_ERROR), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::NetException::NetException(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&) @ 0x000000000fd50fb5 3. /build/src/IO/WriteBufferFromPocoSocket.cpp:171: DB::WriteBufferFromPocoSocket::nextImpl() @ 0x000000000fd525a7 4. /build/src/IO/WriteBuffer.h:53: DB::WriteBuffer::next() @ 0x000000000a0755be 5. /build/src/Server/TCPHandler.cpp:826: DB::TCPHandler::runImpl() @ 0x00000000168e6c9c 6. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 7. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 8. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 9. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 10. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 11. ? @ 0x00007fbc6213eac3 12. ? @ 0x00007fbc621d0850 (version 25.3.6.10636.altinitytest (altinity build)) 2025.07.28 12:02:37.402725 [ 4446 ] {} TCPHandler: Code: 394. DB::Exception: Query was cancelled. (QUERY_WAS_CANCELLED), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000000a074fcb 4. /build/src/Interpreters/ProcessList.cpp:567: DB::QueryStatus::throwQueryWasCancelled() const @ 0x0000000014a4bc85 5. /build/src/Interpreters/ProcessList.cpp:520: DB::QueryStatus::throwProperExceptionIfNeeded(unsigned long const&, unsigned long const&) @ 0x0000000014a4bbd9 6. /build/src/Interpreters/ProcessList.cpp:557: DB::QueryStatus::checkTimeLimit() @ 0x0000000014a4c2cd 7. /build/src/Processors/Executors/PipelineExecutor.cpp:206: DB::PipelineExecutor::finalizeExecution() @ 0x00000000169b13ba 8. /build/src/Processors/Executors/PipelineExecutor.cpp:153: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x00000000169b0584 9. /build/src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:se190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169bfeab 10. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc3d92 11. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fcca080 12. ? @ 0x00007fbc6213eac3 13. ? @ 0x00007fbc621d0850 Job's origin stack trace: 0. /build/src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000000fc33b84 1. /build/src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000000fcc2ea7 2. /build/src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fcc535c 3. /build/src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000000fcc584d 4. /build/src/Common/ThreadPool.h:279: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x00000000169bf193 5. /build/src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x00000000169bf518 6. /build/src/Server/TCPHandler.cpp:1237: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x00000000168f1525 7. /build/src/Server/TCPHandler.cpp:678: DB::TCPHandler::runImpl() @ 0x00000000168e68e5 8. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 9. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 10. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 11. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 12. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 13. ? @ 0x00007fbc6213eac3 14. ? @ 0x00007fbc621d0850 2025.07.28 12:02:37.405232 [ 17255 ] {15d27393-667c-4aa9-9751-c7b84d80d72f} executeQuery: Code: 210. DB::NetException: I/O error: Broken pipe, while writing to socket ([::1]:9000 -> [::1]:56334). (NETWORK_ERROR) (version 25.3.6.10636.altinitytest (altinity build)) (from [::1]:56334) (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. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::NetException::NetException(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&) @ 0x000000000fd50fb5 3. /build/src/IO/WriteBufferFromPocoSocket.cpp:171: DB::WriteBufferFromPocoSocket::nextImpl() @ 0x000000000fd525a7 4. /build/src/IO/WriteBuffer.h:53: DB::WriteBuffer::next() @ 0x000000000a0755be 5. /build/src/Server/TCPHandler.cpp:2590: DB::TCPHandler::sendProgress(DB::QueryState&) @ 0x00000000168f1bfc 6. /build/src/Server/TCPHandler.cpp:1293: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x00000000168f1827 7. /build/src/Server/TCPHandler.cpp:678: DB::TCPHandler::runImpl() @ 0x00000000168e68e5 8. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 9. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 10. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 11. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 12. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 13. ? @ 0x00007fbc6213eac3 14. ? @ 0x00007fbc621d0850 2025.07.28 12:02:37.408034 [ 17255 ] {} TCPHandler: Code: 210. DB::NetException: I/O error: Broken pipe, while writing to socket ([::1]:9000 -> [::1]:56334). (NETWORK_ERROR), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::NetException::NetException(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&) @ 0x000000000fd50fb5 3. /build/src/IO/WriteBufferFromPocoSocket.cpp:171: DB::WriteBufferFromPocoSocket::nextImpl() @ 0x000000000fd525a7 4. /build/src/IO/WriteBuffer.h:53: DB::WriteBuffer::next() @ 0x000000000a0755be 5. /build/src/Server/TCPHandler.cpp:2590: DB::TCPHandler::sendProgress(DB::QueryState&) @ 0x00000000168f1bfc 6. /build/src/Server/TCPHandler.cpp:1293: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x00000000168f1827 7. /build/src/Server/TCPHandler.cpp:678: DB::TCPHandler::runImpl() @ 0x00000000168e68e5 8. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 9. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 10. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 11. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 12. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 13. ? @ 0x00007fbc6213eac3 14. ? @ 0x00007fbc621d0850 2025.07.28 12:02:37.427498 [ 62314 ] {bc2ea9e1-ec86-421d-8cd7-256f79eccc10} executeQuery: Code: 236. DB::NetException: Client has dropped the connection, cancel the query. (ABORTED) (version 25.3.6.10636.altinitytest (altinity build)) (from [::1]:56254) (comment: 02461_cancel_finish_race.sh) (query 1, line 1) (in query: KILL QUERY WHERE current_database = 'test_dtwle8fg' SYNC FORMAT Null), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::NetException::NetException(int, T&&) @ 0x0000000016900f80 3. /build/src/Server/TCPHandler.cpp:2426: DB::TCPHandler::receivePacketsExpectCancel(DB::QueryState&) @ 0x00000000168fba18 4. /build/src/Server/TCPHandler.cpp:1242: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x00000000168f1540 5. /build/src/Server/TCPHandler.cpp:678: DB::TCPHandler::runImpl() @ 0x00000000168e68e5 6. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 7. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 8. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 9. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 10. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 11. ? @ 0x00007fbc6213eac3 12. ? @ 0x00007fbc621d0850 2025.07.28 12:02:37.435556 [ 62056 ] {f1b9af26-06c3-47a2-a1a9-df889117b341} executeQuery: Code: 210. DB::NetException: I/O error: Broken pipe, while writing to socket ([::1]:9000 -> [::1]:56312). (NETWORK_ERROR) (version 25.3.6.10636.altinitytest (altinity build)) (from [::1]:56312) (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. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::NetException::NetException(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&) @ 0x000000000fd50fb5 3. /build/src/IO/WriteBufferFromPocoSocket.cpp:171: DB::WriteBufferFromPocoSocket::nextImpl() @ 0x000000000fd525a7 4. /build/src/IO/WriteBuffer.h:53: DB::WriteBuffer::next() @ 0x000000000a0755be 5. /build/src/Server/TCPHandler.cpp:1422: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x00000000168f181c 6. /build/src/Server/TCPHandler.cpp:678: DB::TCPHandler::runImpl() @ 0x00000000168e68e5 7. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 8. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 9. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 10. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 11. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 12. ? @ 0x00007fbc6213eac3 13. ? @ 0x00007fbc621d0850 2025.07.28 12:02:37.437391 [ 62056 ] {} TCPHandler: Code: 210. DB::NetException: I/O error: Broken pipe, while writing to socket ([::1]:9000 -> [::1]:56312). (NETWORK_ERROR), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::NetException::NetException(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&) @ 0x000000000fd50fb5 3. /build/src/IO/WriteBufferFromPocoSocket.cpp:171: DB::WriteBufferFromPocoSocket::nextImpl() @ 0x000000000fd525a7 4. /build/src/IO/WriteBuffer.h:53: DB::WriteBuffer::next() @ 0x000000000a0755be 5. /build/src/Server/TCPHandler.cpp:1422: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x00000000168f181c 6. /build/src/Server/TCPHandler.cpp:678: DB::TCPHandler::runImpl() @ 0x00000000168e68e5 7. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 8. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 9. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 10. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 11. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 12. ? @ 0x00007fbc6213eac3 13. ? @ 0x00007fbc621d0850 2025.07.28 12:02:37.447068 [ 62314 ] {bc2ea9e1-ec86-421d-8cd7-256f79eccc10} 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]:56254). (NETWORK_ERROR), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::NetException::NetException(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&) @ 0x000000000fd50fb5 3. /build/src/IO/WriteBufferFromPocoSocket.cpp:171: DB::WriteBufferFromPocoSocket::nextImpl() @ 0x000000000fd525a7 4. /build/src/IO/WriteBuffer.h:53: DB::WriteBuffer::next() @ 0x000000000a0755be 5. /build/src/Server/TCPHandler.cpp:826: DB::TCPHandler::runImpl() @ 0x00000000168e6c9c 6. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 7. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 8. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 9. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 10. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 11. ? @ 0x00007fbc6213eac3 12. ? @ 0x00007fbc621d0850 (version 25.3.6.10636.altinitytest (altinity build)) 2025.07.28 12:02:37.453598 [ 62314 ] {} 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. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::NetException::NetException(int, T&&) @ 0x0000000016900f80 3. /build/src/Server/TCPHandler.cpp:2426: DB::TCPHandler::receivePacketsExpectCancel(DB::QueryState&) @ 0x00000000168fba18 4. /build/src/Server/TCPHandler.cpp:1242: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x00000000168f1540 5. /build/src/Server/TCPHandler.cpp:678: DB::TCPHandler::runImpl() @ 0x00000000168e68e5 6. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 7. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 8. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 9. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 10. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 11. ? @ 0x00007fbc6213eac3 12. ? @ 0x00007fbc621d0850 2025.07.28 12:02:37.499422 [ 7625 ] {a3c851bd-9d05-4977-bcdd-1a4eed477a7f} executeQuery: Code: 210. DB::NetException: I/O error: Broken pipe, while writing to socket ([::1]:9000 -> [::1]:56370). (NETWORK_ERROR) (version 25.3.6.10636.altinitytest (altinity build)) (from [::1]:56370) (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. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::NetException::NetException(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&) @ 0x000000000fd50fb5 3. /build/src/IO/WriteBufferFromPocoSocket.cpp:171: DB::WriteBufferFromPocoSocket::nextImpl() @ 0x000000000fd525a7 4. /build/src/IO/WriteBuffer.h:53: DB::WriteBuffer::next() @ 0x000000000a0755be 5. /build/src/Server/TCPHandler.cpp:1422: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x00000000168f181c 6. /build/src/Server/TCPHandler.cpp:678: DB::TCPHandler::runImpl() @ 0x00000000168e68e5 7. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 8. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 9. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 10. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 11. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 12. ? @ 0x00007fbc6213eac3 13. ? @ 0x00007fbc621d0850 2025.07.28 12:02:37.507198 [ 7625 ] {} TCPHandler: Code: 210. DB::NetException: I/O error: Broken pipe, while writing to socket ([::1]:9000 -> [::1]:56370). (NETWORK_ERROR), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::NetException::NetException(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&) @ 0x000000000fd50fb5 3. /build/src/IO/WriteBufferFromPocoSocket.cpp:171: DB::WriteBufferFromPocoSocket::nextImpl() @ 0x000000000fd525a7 4. /build/src/IO/WriteBuffer.h:53: DB::WriteBuffer::next() @ 0x000000000a0755be 5. /build/src/Server/TCPHandler.cpp:1422: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x00000000168f181c 6. /build/src/Server/TCPHandler.cpp:678: DB::TCPHandler::runImpl() @ 0x00000000168e68e5 7. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 8. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 9. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 10. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 11. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 12. ? @ 0x00007fbc6213eac3 13. ? @ 0x00007fbc621d0850 2025.07.28 12:02:37.516923 [ 5879 ] {25087112-9387-4bbd-8e1d-9e9b273ccfc8} executeQuery: Code: 210. DB::NetException: I/O error: Broken pipe, while writing to socket ([::1]:9000 -> [::1]:56290). (NETWORK_ERROR) (version 25.3.6.10636.altinitytest (altinity build)) (from [::1]:56290) (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. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::NetException::NetException(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&) @ 0x000000000fd50fb5 3. /build/src/IO/WriteBufferFromPocoSocket.cpp:171: DB::WriteBufferFromPocoSocket::nextImpl() @ 0x000000000fd525a7 4. /build/src/IO/WriteBuffer.h:53: DB::WriteBuffer::next() @ 0x000000000a0755be 5. /build/src/Server/TCPHandler.cpp:1422: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x00000000168f181c 6. /build/src/Server/TCPHandler.cpp:678: DB::TCPHandler::runImpl() @ 0x00000000168e68e5 7. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 8. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 9. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 10. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 11. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 12. ? @ 0x00007fbc6213eac3 13. ? @ 0x00007fbc621d0850 2025.07.28 12:02:37.519716 [ 5879 ] {} TCPHandler: Code: 210. DB::NetException: I/O error: Broken pipe, while writing to socket ([::1]:9000 -> [::1]:56290). (NETWORK_ERROR), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::NetException::NetException(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&) @ 0x000000000fd50fb5 3. /build/src/IO/WriteBufferFromPocoSocket.cpp:171: DB::WriteBufferFromPocoSocket::nextImpl() @ 0x000000000fd525a7 4. /build/src/IO/WriteBuffer.h:53: DB::WriteBuffer::next() @ 0x000000000a0755be 5. /build/src/Server/TCPHandler.cpp:1422: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x00000000168f181c 6. /build/src/Server/TCPHandler.cpp:678: DB::TCPHandler::runImpl() @ 0x00000000168e68e5 7. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 8. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 9. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 10. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 11. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 12. ? @ 0x00007fbc6213eac3 13. ? @ 0x00007fbc621d0850 2025.07.28 12:02:37.526405 [ 62058 ] {000b200a-fb62-4551-b424-08ff7e5d6ce7} executeQuery: Code: 210. DB::NetException: I/O error: Broken pipe, while writing to socket ([::1]:9000 -> [::1]:56280). (NETWORK_ERROR) (version 25.3.6.10636.altinitytest (altinity build)) (from [::1]:56280) (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. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::NetException::NetException(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&) @ 0x000000000fd50fb5 3. /build/src/IO/WriteBufferFromPocoSocket.cpp:171: DB::WriteBufferFromPocoSocket::nextImpl() @ 0x000000000fd525a7 4. /build/src/IO/WriteBuffer.h:53: DB::WriteBuffer::next() @ 0x000000000a0755be 5. /build/src/Server/TCPHandler.cpp:1422: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x00000000168f181c 6. /build/src/Server/TCPHandler.cpp:678: DB::TCPHandler::runImpl() @ 0x00000000168e68e5 7. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 8. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 9. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 10. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 11. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 12. ? @ 0x00007fbc6213eac3 13. ? @ 0x00007fbc621d0850 2025.07.28 12:02:37.528113 [ 62058 ] {} TCPHandler: Code: 210. DB::NetException: I/O error: Broken pipe, while writing to socket ([::1]:9000 -> [::1]:56280). (NETWORK_ERROR), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::NetException::NetException(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&) @ 0x000000000fd50fb5 3. /build/src/IO/WriteBufferFromPocoSocket.cpp:171: DB::WriteBufferFromPocoSocket::nextImpl() @ 0x000000000fd525a7 4. /build/src/IO/WriteBuffer.h:53: DB::WriteBuffer::next() @ 0x000000000a0755be 5. /build/src/Server/TCPHandler.cpp:1422: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x00000000168f181c 6. /build/src/Server/TCPHandler.cpp:678: DB::TCPHandler::runImpl() @ 0x00000000168e68e5 7. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 8. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 9. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 10. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 11. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 12. ? @ 0x00007fbc6213eac3 13. ? @ 0x00007fbc621d0850 2025.07.28 12:02:37.552478 [ 17232 ] {d67420e0-a4d4-4239-968d-b7d91cdd4dcf} executeQuery: Code: 210. DB::NetException: I/O error: Broken pipe, while writing to socket ([::1]:9000 -> [::1]:56378). (NETWORK_ERROR) (version 25.3.6.10636.altinitytest (altinity build)) (from [::1]:56378) (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. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::NetException::NetException(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&) @ 0x000000000fd50fb5 3. /build/src/IO/WriteBufferFromPocoSocket.cpp:171: DB::WriteBufferFromPocoSocket::nextImpl() @ 0x000000000fd525a7 4. /build/src/IO/WriteBuffer.h:53: DB::WriteBuffer::next() @ 0x000000000a0755be 5. /build/src/Server/TCPHandler.cpp:1422: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x00000000168f181c 6. /build/src/Server/TCPHandler.cpp:678: DB::TCPHandler::runImpl() @ 0x00000000168e68e5 7. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 8. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 9. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 10. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 11. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 12. ? @ 0x00007fbc6213eac3 13. ? @ 0x00007fbc621d0850 2025.07.28 12:02:37.556218 [ 17232 ] {} TCPHandler: Code: 210. DB::NetException: I/O error: Broken pipe, while writing to socket ([::1]:9000 -> [::1]:56378). (NETWORK_ERROR), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::NetException::NetException(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&) @ 0x000000000fd50fb5 3. /build/src/IO/WriteBufferFromPocoSocket.cpp:171: DB::WriteBufferFromPocoSocket::nextImpl() @ 0x000000000fd525a7 4. /build/src/IO/WriteBuffer.h:53: DB::WriteBuffer::next() @ 0x000000000a0755be 5. /build/src/Server/TCPHandler.cpp:1422: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x00000000168f181c 6. /build/src/Server/TCPHandler.cpp:678: DB::TCPHandler::runImpl() @ 0x00000000168e68e5 7. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 8. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 9. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 10. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 11. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 12. ? @ 0x00007fbc6213eac3 13. ? @ 0x00007fbc621d0850 2025.07.28 12:02:37.588730 [ 17256 ] {108ef1d5-74e3-434e-ad30-7335be1c0718} executeQuery: Code: 236. DB::NetException: Client has dropped the connection, cancel the query. (ABORTED) (version 25.3.6.10636.altinitytest (altinity build)) (from [::1]:56344) (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. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::NetException::NetException(int, T&&) @ 0x0000000016900f80 3. /build/src/Server/TCPHandler.cpp:2426: DB::TCPHandler::receivePacketsExpectCancel(DB::QueryState&) @ 0x00000000168fba18 4. /build/src/Server/TCPHandler.cpp:1242: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x00000000168f1540 5. /build/src/Server/TCPHandler.cpp:678: DB::TCPHandler::runImpl() @ 0x00000000168e68e5 6. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 7. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 8. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 9. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 10. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 11. ? @ 0x00007fbc6213eac3 12. ? @ 0x00007fbc621d0850 2025.07.28 12:02:37.590942 [ 17256 ] {108ef1d5-74e3-434e-ad30-7335be1c0718} 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]:56344). (NETWORK_ERROR), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::NetException::NetException(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&) @ 0x000000000fd50fb5 3. /build/src/IO/WriteBufferFromPocoSocket.cpp:171: DB::WriteBufferFromPocoSocket::nextImpl() @ 0x000000000fd525a7 4. /build/src/IO/WriteBuffer.h:53: DB::WriteBuffer::next() @ 0x000000000a0755be 5. /build/src/Server/TCPHandler.cpp:2620: DB::TCPHandler::sendLogs(DB::QueryState&) @ 0x00000000168f1e17 6. /build/src/Server/TCPHandler.cpp:821: DB::TCPHandler::runImpl() @ 0x00000000168e6c63 7. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 8. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 9. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 10. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 11. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 12. ? @ 0x00007fbc6213eac3 13. ? @ 0x00007fbc621d0850 (version 25.3.6.10636.altinitytest (altinity build)) 2025.07.28 12:02:37.592633 [ 17256 ] {} 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. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::NetException::NetException(int, T&&) @ 0x0000000016900f80 3. /build/src/Server/TCPHandler.cpp:2426: DB::TCPHandler::receivePacketsExpectCancel(DB::QueryState&) @ 0x00000000168fba18 4. /build/src/Server/TCPHandler.cpp:1242: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x00000000168f1540 5. /build/src/Server/TCPHandler.cpp:678: DB::TCPHandler::runImpl() @ 0x00000000168e68e5 6. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 7. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 8. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 9. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 10. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 11. ? @ 0x00007fbc6213eac3 12. ? @ 0x00007fbc621d0850 2025.07.28 12:02:37.613683 [ 63425 ] {2c894d41-5c52-4be2-8395-323faa64c291} executeQuery: Code: 394. DB::Exception: Query was cancelled. (QUERY_WAS_CANCELLED) (version 25.3.6.10636.altinitytest (altinity build)) (from [::1]:56300) (comment: 02461_cancel_finish_race.sh) (query 1, line 1) (in query: KILL QUERY WHERE current_database = 'test_dtwle8fg' SYNC FORMAT Null), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000000a074fcb 4. /build/src/Interpreters/ProcessList.cpp:567: DB::QueryStatus::throwQueryWasCancelled() const @ 0x0000000014a4bc85 5. /build/src/Interpreters/ProcessList.cpp:520: DB::QueryStatus::throwProperExceptionIfNeeded(unsigned long const&, unsigned long const&) @ 0x0000000014a4bbd9 6. /build/src/Interpreters/ProcessList.cpp:557: DB::QueryStatus::checkTimeLimit() @ 0x0000000014a4c2cd 7. /build/src/Processors/Executors/PipelineExecutor.cpp:206: DB::PipelineExecutor::finalizeExecution() @ 0x00000000169b13ba 8. /build/src/Processors/Executors/PipelineExecutor.cpp:153: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x00000000169b0584 9. /build/src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:se190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169bfeab 10. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc3d92 11. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fcca080 12. ? @ 0x00007fbc6213eac3 13. ? @ 0x00007fbc621d0850 2025.07.28 12:02:37.620742 [ 63425 ] {2c894d41-5c52-4be2-8395-323faa64c291} 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]:56300). (NETWORK_ERROR), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::NetException::NetException(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&) @ 0x000000000fd50fb5 3. /build/src/IO/WriteBufferFromPocoSocket.cpp:171: DB::WriteBufferFromPocoSocket::nextImpl() @ 0x000000000fd525a7 4. /build/src/IO/WriteBuffer.h:53: DB::WriteBuffer::next() @ 0x000000000a0755be 5. /build/src/Server/TCPHandler.cpp:2620: DB::TCPHandler::sendLogs(DB::QueryState&) @ 0x00000000168f1e17 6. /build/src/Server/TCPHandler.cpp:821: DB::TCPHandler::runImpl() @ 0x00000000168e6c63 7. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 8. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 9. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 10. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 11. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 12. ? @ 0x00007fbc6213eac3 13. ? @ 0x00007fbc621d0850 (version 25.3.6.10636.altinitytest (altinity build)) 2025.07.28 12:02:37.644875 [ 63425 ] {} TCPHandler: Code: 394. DB::Exception: Query was cancelled. (QUERY_WAS_CANCELLED), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000000a074fcb 4. /build/src/Interpreters/ProcessList.cpp:567: DB::QueryStatus::throwQueryWasCancelled() const @ 0x0000000014a4bc85 5. /build/src/Interpreters/ProcessList.cpp:520: DB::QueryStatus::throwProperExceptionIfNeeded(unsigned long const&, unsigned long const&) @ 0x0000000014a4bbd9 6. /build/src/Interpreters/ProcessList.cpp:557: DB::QueryStatus::checkTimeLimit() @ 0x0000000014a4c2cd 7. /build/src/Processors/Executors/PipelineExecutor.cpp:206: DB::PipelineExecutor::finalizeExecution() @ 0x00000000169b13ba 8. /build/src/Processors/Executors/PipelineExecutor.cpp:153: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x00000000169b0584 9. /build/src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:se190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169bfeab 10. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc3d92 11. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fcca080 12. ? @ 0x00007fbc6213eac3 13. ? @ 0x00007fbc621d0850 Job's origin stack trace: 0. /build/src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000000fc33b84 1. /build/src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000000fcc2ea7 2. /build/src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fcc535c 3. /build/src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000000fcc584d 4. /build/src/Common/ThreadPool.h:279: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x00000000169bf193 5. /build/src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x00000000169bf518 6. /build/src/Server/TCPHandler.cpp:1237: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x00000000168f1525 7. /build/src/Server/TCPHandler.cpp:678: DB::TCPHandler::runImpl() @ 0x00000000168e68e5 8. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 9. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 10. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 11. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 12. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 13. ? @ 0x00007fbc6213eac3 14. ? @ 0x00007fbc621d0850 2025.07.28 12:02:37.714818 [ 62325 ] {bedb8bc7-f95f-4e29-ab9e-0bf25a7b5db7} executeQuery: Code: 236. DB::NetException: Client has dropped the connection, cancel the query. (ABORTED) (version 25.3.6.10636.altinitytest (altinity build)) (from [::1]:56358) (comment: 02461_cancel_finish_race.sh) (query 1, line 1) (in query: KILL QUERY WHERE current_database = 'test_dtwle8fg' SYNC FORMAT Null), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::NetException::NetException(int, T&&) @ 0x0000000016900f80 3. /build/src/Server/TCPHandler.cpp:2426: DB::TCPHandler::receivePacketsExpectCancel(DB::QueryState&) @ 0x00000000168fba18 4. /build/src/Server/TCPHandler.cpp:1242: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x00000000168f1540 5. /build/src/Server/TCPHandler.cpp:678: DB::TCPHandler::runImpl() @ 0x00000000168e68e5 6. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 7. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 8. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 9. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 10. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 11. ? @ 0x00007fbc6213eac3 12. ? @ 0x00007fbc621d0850 2025.07.28 12:02:37.716934 [ 62325 ] {bedb8bc7-f95f-4e29-ab9e-0bf25a7b5db7} 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]:56358). (NETWORK_ERROR), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::NetException::NetException(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&) @ 0x000000000fd50fb5 3. /build/src/IO/WriteBufferFromPocoSocket.cpp:171: DB::WriteBufferFromPocoSocket::nextImpl() @ 0x000000000fd525a7 4. /build/src/IO/WriteBuffer.h:53: DB::WriteBuffer::next() @ 0x000000000a0755be 5. /build/src/Server/TCPHandler.cpp:2620: DB::TCPHandler::sendLogs(DB::QueryState&) @ 0x00000000168f1e17 6. /build/src/Server/TCPHandler.cpp:821: DB::TCPHandler::runImpl() @ 0x00000000168e6c63 7. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 8. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 9. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 10. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 11. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 12. ? @ 0x00007fbc6213eac3 13. ? @ 0x00007fbc621d0850 (version 25.3.6.10636.altinitytest (altinity build)) 2025.07.28 12:02:37.718644 [ 62325 ] {} 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. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::NetException::NetException(int, T&&) @ 0x0000000016900f80 3. /build/src/Server/TCPHandler.cpp:2426: DB::TCPHandler::receivePacketsExpectCancel(DB::QueryState&) @ 0x00000000168fba18 4. /build/src/Server/TCPHandler.cpp:1242: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x00000000168f1540 5. /build/src/Server/TCPHandler.cpp:678: DB::TCPHandler::runImpl() @ 0x00000000168e68e5 6. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 7. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 8. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 9. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 10. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 11. ? @ 0x00007fbc6213eac3 12. ? @ 0x00007fbc621d0850 2025.07.28 12:02:37.915420 [ 3965 ] {} test_13.rmt2 (7f9b740d-015c-470e-8cc6-8ba33be0dc63): auto DB::StorageReplicatedMergeTree::processQueueEntry(ReplicatedMergeTreeQueue::SelectedEntryPtr)::(anonymous class)::operator()(LogEntryPtr &) const: Code: 86. DB::HTTPException: Received error from remote server http://146b4357c08d:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Ftest%2F01165%2Ftest_13%2Frmt%2Freplicas%2F1&part=20250728_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.6.10636.altinitytest (altinity build)) '. (RECEIVED_ERROR_FROM_REMOTE_IO_SERVER), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.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 const&, int&&, String const&, unsigned long&&, String const&) @ 0x000000000feda8d9 4. /build/src/IO/HTTPCommon.cpp:104: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x000000000feda6e2 5. /build/src/IO/HTTPCommon.cpp:93: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x000000000feda537 6. /build/src/IO/ReadWriteBufferFromHTTP.cpp:277: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x000000001184a4c4 7. /build/src/IO/ReadWriteBufferFromHTTP.cpp:285: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x000000001184a615 8. /build/src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x000000001184ae59 9. /build/src/IO/ReadWriteBufferFromHTTP.cpp:472: void std::__function::__policy_invoker::__call_impl[abi:se190107]>(std::__function::__policy_storage const*) @ 0x000000001184cedd 10. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001184858b 11. /build/src/IO/ReadWriteBufferFromHTTP.cpp:465: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x000000001184bf0b 12. /build/src/IO/ReadBuffer.h:60: DB::ReadBuffer::next() @ 0x000000000a148c7b 13. /build/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) @ 0x0000000011849fb2 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]>&)>&, 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&) @ 0x0000000011841980 15. /build/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) @ 0x000000001621208e 16. /build/src/Storages/StorageReplicatedMergeTree.cpp:5228: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl[abi:se190107] const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000015f9a5fe 17. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000015ed8bfd 18. /build/src/Storages/StorageReplicatedMergeTree.cpp:2514: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x0000000015ec9aab 19. /build/src/Storages/StorageReplicatedMergeTree.cpp:2349: DB::StorageReplicatedMergeTree::executeLogEntry(DB::ReplicatedMergeTreeLogEntry&) @ 0x0000000015eba91b 20. /build/src/Storages/StorageReplicatedMergeTree.cpp:3876: bool std::__function::__policy_invoker&)>::__call_impl[abi:se190107])::$_1, bool (std::shared_ptr&)>>(std::__function::__policy_storage const*, std::shared_ptr&) @ 0x0000000015f9837e 21. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000165d6fc3 22. /build/src/Storages/StorageReplicatedMergeTree.cpp:3872: DB::StorageReplicatedMergeTree::processQueueEntry(std::shared_ptr) @ 0x0000000015efc18a 23. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001624c1b2 24. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000162f9c70 25. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x00000000162fa55a 26. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc6653 27. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000000fccc4c3 28. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc3d92 29. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fcca080 30. ? @ 0x00007fbc6213eac3 31. ? @ 0x00007fbc621d0850 (version 25.3.6.10636.altinitytest (altinity build)) 2025.07.28 12:02:38.059742 [ 17203 ] {5f918e2e-8f52-42df-8ef0-ae6eb4eceb47} executeQuery: Code: 60. DB::Exception: Table test_5.test_optimize_exception_replicated does not exist. Maybe you meant test_5.test_optimize_exception?. (UNKNOWN_TABLE) (version 25.3.6.10636.altinitytest (altinity build)) (from [::1]:56422) (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. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/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&&) @ 0x000000000a1011eb 4. /build/src/Databases/IDatabase.cpp:42: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x0000000013dd57aa 5. /build/src/Interpreters/DatabaseCatalog.cpp:442: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x00000000144f0869 6. /build/src/Interpreters/DatabaseCatalog.cpp:976: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x00000000144f6c88 7. /build/src/Interpreters/InterpreterInsertQuery.cpp:169: DB::InterpreterInsertQuery::getTable(DB::ASTInsertQuery&) @ 0x000000001492bf04 8. /build/src/Interpreters/InterpreterInsertQuery.cpp:829: DB::InterpreterInsertQuery::execute() @ 0x0000000014933938 9. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88dc9 10. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 11. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 12. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 13. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 14. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 16. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 17. ? @ 0x00007fbc6213eac3 18. ? @ 0x00007fbc621d0850 2025.07.28 12:02:38.097505 [ 17203 ] {} TCPHandler: Code: 60. DB::Exception: Table test_5.test_optimize_exception_replicated does not exist. Maybe you meant test_5.test_optimize_exception?. (UNKNOWN_TABLE), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/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&&) @ 0x000000000a1011eb 4. /build/src/Databases/IDatabase.cpp:42: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x0000000013dd57aa 5. /build/src/Interpreters/DatabaseCatalog.cpp:442: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x00000000144f0869 6. /build/src/Interpreters/DatabaseCatalog.cpp:976: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x00000000144f6c88 7. /build/src/Interpreters/InterpreterInsertQuery.cpp:169: DB::InterpreterInsertQuery::getTable(DB::ASTInsertQuery&) @ 0x000000001492bf04 8. /build/src/Interpreters/InterpreterInsertQuery.cpp:829: DB::InterpreterInsertQuery::execute() @ 0x0000000014933938 9. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88dc9 10. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 11. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 12. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 13. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 14. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 16. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 17. ? @ 0x00007fbc6213eac3 18. ? @ 0x00007fbc621d0850 2025.07.28 12:02:38.250776 [ 3962 ] {} test_13.rmt2 (7f9b740d-015c-470e-8cc6-8ba33be0dc63): auto DB::StorageReplicatedMergeTree::processQueueEntry(ReplicatedMergeTreeQueue::SelectedEntryPtr)::(anonymous class)::operator()(LogEntryPtr &) const: Code: 86. DB::HTTPException: Received error from remote server http://146b4357c08d:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Ftest%2F01165%2Ftest_13%2Frmt%2Freplicas%2F1&part=20250728_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.6.10636.altinitytest (altinity build)) '. (RECEIVED_ERROR_FROM_REMOTE_IO_SERVER), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.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 const&, int&&, String const&, unsigned long&&, String const&) @ 0x000000000feda8d9 4. /build/src/IO/HTTPCommon.cpp:104: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x000000000feda6e2 5. /build/src/IO/HTTPCommon.cpp:93: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x000000000feda537 6. /build/src/IO/ReadWriteBufferFromHTTP.cpp:277: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x000000001184a4c4 7. /build/src/IO/ReadWriteBufferFromHTTP.cpp:285: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x000000001184a615 8. /build/src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x000000001184ae59 9. /build/src/IO/ReadWriteBufferFromHTTP.cpp:472: void std::__function::__policy_invoker::__call_impl[abi:se190107]>(std::__function::__policy_storage const*) @ 0x000000001184cedd 10. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001184858b 11. /build/src/IO/ReadWriteBufferFromHTTP.cpp:465: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x000000001184bf0b 12. /build/src/IO/ReadBuffer.h:60: DB::ReadBuffer::next() @ 0x000000000a148c7b 13. /build/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) @ 0x0000000011849fb2 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]>&)>&, 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&) @ 0x0000000011841980 15. /build/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) @ 0x000000001621208e 16. /build/src/Storages/StorageReplicatedMergeTree.cpp:5228: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl[abi:se190107] const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000015f9a5fe 17. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000015ed8bfd 18. /build/src/Storages/StorageReplicatedMergeTree.cpp:2514: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x0000000015ec9aab 19. /build/src/Storages/StorageReplicatedMergeTree.cpp:2349: DB::StorageReplicatedMergeTree::executeLogEntry(DB::ReplicatedMergeTreeLogEntry&) @ 0x0000000015eba91b 20. /build/src/Storages/StorageReplicatedMergeTree.cpp:3876: bool std::__function::__policy_invoker&)>::__call_impl[abi:se190107])::$_1, bool (std::shared_ptr&)>>(std::__function::__policy_storage const*, std::shared_ptr&) @ 0x0000000015f9837e 21. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000165d6fc3 22. /build/src/Storages/StorageReplicatedMergeTree.cpp:3872: DB::StorageReplicatedMergeTree::processQueueEntry(std::shared_ptr) @ 0x0000000015efc18a 23. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001624c1b2 24. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000162f9c70 25. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x00000000162fa55a 26. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc6653 27. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000000fccc4c3 28. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc3d92 29. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fcca080 30. ? @ 0x00007fbc6213eac3 31. ? @ 0x00007fbc621d0850 (version 25.3.6.10636.altinitytest (altinity build)) 2025.07.28 12:02:38.276879 [ 17203 ] {d9a03b0d-7139-4565-8627-7eee74ce3a03} executeQuery: Code: 60. DB::Exception: Table test_5.test_optimize_exception_replicated does not exist. Maybe you meant test_5.test_optimize_exception?. (UNKNOWN_TABLE) (version 25.3.6.10636.altinitytest (altinity build)) (from [::1]:56430) (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. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/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&&) @ 0x000000000a1011eb 4. /build/src/Databases/IDatabase.cpp:42: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x0000000013dd57aa 5. /build/src/Interpreters/DatabaseCatalog.cpp:442: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x00000000144f0869 6. /build/src/Interpreters/DatabaseCatalog.cpp:976: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x00000000144f6c88 7. /build/src/Interpreters/InterpreterInsertQuery.cpp:169: DB::InterpreterInsertQuery::getTable(DB::ASTInsertQuery&) @ 0x000000001492bf04 8. /build/src/Interpreters/InterpreterInsertQuery.cpp:829: DB::InterpreterInsertQuery::execute() @ 0x0000000014933938 9. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88dc9 10. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 11. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 12. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 13. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 14. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 16. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 17. ? @ 0x00007fbc6213eac3 18. ? @ 0x00007fbc621d0850 2025.07.28 12:02:38.299975 [ 17203 ] {} TCPHandler: Code: 60. DB::Exception: Table test_5.test_optimize_exception_replicated does not exist. Maybe you meant test_5.test_optimize_exception?. (UNKNOWN_TABLE), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/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&&) @ 0x000000000a1011eb 4. /build/src/Databases/IDatabase.cpp:42: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x0000000013dd57aa 5. /build/src/Interpreters/DatabaseCatalog.cpp:442: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x00000000144f0869 6. /build/src/Interpreters/DatabaseCatalog.cpp:976: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x00000000144f6c88 7. /build/src/Interpreters/InterpreterInsertQuery.cpp:169: DB::InterpreterInsertQuery::getTable(DB::ASTInsertQuery&) @ 0x000000001492bf04 8. /build/src/Interpreters/InterpreterInsertQuery.cpp:829: DB::InterpreterInsertQuery::execute() @ 0x0000000014933938 9. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88dc9 10. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 11. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 12. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 13. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 14. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 16. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 17. ? @ 0x00007fbc6213eac3 18. ? @ 0x00007fbc621d0850 2025.07.28 12:02:38.914470 [ 17203 ] {970189cf-a88a-4698-946f-4ca069008c14} executeQuery: Code: 60. DB::Exception: Table test_5.test_optimize_exception_replicated does not exist. Maybe you meant test_5.test_optimize_exception?. (UNKNOWN_TABLE) (version 25.3.6.10636.altinitytest (altinity build)) (from [::1]:56468) (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. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/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&&) @ 0x000000000a1011eb 4. /build/src/Databases/IDatabase.cpp:42: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x0000000013dd57aa 5. /build/src/Interpreters/DatabaseCatalog.cpp:442: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x00000000144f0869 6. /build/src/Interpreters/DatabaseCatalog.cpp:976: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x00000000144f6c88 7. /build/src/Interpreters/InterpreterOptimizeQuery.cpp:40: DB::InterpreterOptimizeQuery::execute() @ 0x0000000014cd71de 8. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88dc9 9. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 10. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 11. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 12. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 13. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 14. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 15. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 16. ? @ 0x00007fbc6213eac3 17. ? @ 0x00007fbc621d0850 2025.07.28 12:02:38.919671 [ 17203 ] {} TCPHandler: Code: 60. DB::Exception: Table test_5.test_optimize_exception_replicated does not exist. Maybe you meant test_5.test_optimize_exception?. (UNKNOWN_TABLE), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/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&&) @ 0x000000000a1011eb 4. /build/src/Databases/IDatabase.cpp:42: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x0000000013dd57aa 5. /build/src/Interpreters/DatabaseCatalog.cpp:442: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x00000000144f0869 6. /build/src/Interpreters/DatabaseCatalog.cpp:976: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x00000000144f6c88 7. /build/src/Interpreters/InterpreterOptimizeQuery.cpp:40: DB::InterpreterOptimizeQuery::execute() @ 0x0000000014cd71de 8. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88dc9 9. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 10. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 11. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 12. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 13. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 14. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 15. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 16. ? @ 0x00007fbc6213eac3 17. ? @ 0x00007fbc621d0850 2025.07.28 12:02:39.064444 [ 3968 ] {} test_13.rmt2 (7f9b740d-015c-470e-8cc6-8ba33be0dc63): auto DB::StorageReplicatedMergeTree::processQueueEntry(ReplicatedMergeTreeQueue::SelectedEntryPtr)::(anonymous class)::operator()(LogEntryPtr &) const: Code: 86. DB::HTTPException: Received error from remote server http://146b4357c08d:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Ftest%2F01165%2Ftest_13%2Frmt%2Freplicas%2F1&part=20250728_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.6.10636.altinitytest (altinity build)) '. (RECEIVED_ERROR_FROM_REMOTE_IO_SERVER), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.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 const&, int&&, String const&, unsigned long&&, String const&) @ 0x000000000feda8d9 4. /build/src/IO/HTTPCommon.cpp:104: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x000000000feda6e2 5. /build/src/IO/HTTPCommon.cpp:93: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x000000000feda537 6. /build/src/IO/ReadWriteBufferFromHTTP.cpp:277: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x000000001184a4c4 7. /build/src/IO/ReadWriteBufferFromHTTP.cpp:285: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x000000001184a615 8. /build/src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x000000001184ae59 9. /build/src/IO/ReadWriteBufferFromHTTP.cpp:472: void std::__function::__policy_invoker::__call_impl[abi:se190107]>(std::__function::__policy_storage const*) @ 0x000000001184cedd 10. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001184858b 11. /build/src/IO/ReadWriteBufferFromHTTP.cpp:465: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x000000001184bf0b 12. /build/src/IO/ReadBuffer.h:60: DB::ReadBuffer::next() @ 0x000000000a148c7b 13. /build/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) @ 0x0000000011849fb2 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]>&)>&, 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&) @ 0x0000000011841980 15. /build/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) @ 0x000000001621208e 16. /build/src/Storages/StorageReplicatedMergeTree.cpp:5228: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl[abi:se190107] const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000015f9a5fe 17. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000015ed8bfd 18. /build/src/Storages/StorageReplicatedMergeTree.cpp:2514: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x0000000015ec9aab 19. /build/src/Storages/StorageReplicatedMergeTree.cpp:2349: DB::StorageReplicatedMergeTree::executeLogEntry(DB::ReplicatedMergeTreeLogEntry&) @ 0x0000000015eba91b 20. /build/src/Storages/StorageReplicatedMergeTree.cpp:3876: bool std::__function::__policy_invoker&)>::__call_impl[abi:se190107])::$_1, bool (std::shared_ptr&)>>(std::__function::__policy_storage const*, std::shared_ptr&) @ 0x0000000015f9837e 21. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000165d6fc3 22. /build/src/Storages/StorageReplicatedMergeTree.cpp:3872: DB::StorageReplicatedMergeTree::processQueueEntry(std::shared_ptr) @ 0x0000000015efc18a 23. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001624c1b2 24. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000162f9c70 25. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x00000000162fa55a 26. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc6653 27. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000000fccc4c3 28. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc3d92 29. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fcca080 30. ? @ 0x00007fbc6213eac3 31. ? @ 0x00007fbc621d0850 (version 25.3.6.10636.altinitytest (altinity build)) 2025.07.28 12:02:39.240755 [ 3963 ] {} test_13.rmt2 (7f9b740d-015c-470e-8cc6-8ba33be0dc63): auto DB::StorageReplicatedMergeTree::processQueueEntry(ReplicatedMergeTreeQueue::SelectedEntryPtr)::(anonymous class)::operator()(LogEntryPtr &) const: Code: 86. DB::HTTPException: Received error from remote server http://146b4357c08d:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Ftest%2F01165%2Ftest_13%2Frmt%2Freplicas%2F1&part=20250728_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.6.10636.altinitytest (altinity build)) '. (RECEIVED_ERROR_FROM_REMOTE_IO_SERVER), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.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 const&, int&&, String const&, unsigned long&&, String const&) @ 0x000000000feda8d9 4. /build/src/IO/HTTPCommon.cpp:104: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x000000000feda6e2 5. /build/src/IO/HTTPCommon.cpp:93: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x000000000feda537 6. /build/src/IO/ReadWriteBufferFromHTTP.cpp:277: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x000000001184a4c4 7. /build/src/IO/ReadWriteBufferFromHTTP.cpp:285: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x000000001184a615 8. /build/src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x000000001184ae59 9. /build/src/IO/ReadWriteBufferFromHTTP.cpp:472: void std::__function::__policy_invoker::__call_impl[abi:se190107]>(std::__function::__policy_storage const*) @ 0x000000001184cedd 10. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001184858b 11. /build/src/IO/ReadWriteBufferFromHTTP.cpp:465: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x000000001184bf0b 12. /build/src/IO/ReadBuffer.h:60: DB::ReadBuffer::next() @ 0x000000000a148c7b 13. /build/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) @ 0x0000000011849fb2 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]>&)>&, 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&) @ 0x0000000011841980 15. /build/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) @ 0x000000001621208e 16. /build/src/Storages/StorageReplicatedMergeTree.cpp:5228: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl[abi:se190107] const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000015f9a5fe 17. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000015ed8bfd 18. /build/src/Storages/StorageReplicatedMergeTree.cpp:2514: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x0000000015ec9aab 19. /build/src/Storages/StorageReplicatedMergeTree.cpp:2349: DB::StorageReplicatedMergeTree::executeLogEntry(DB::ReplicatedMergeTreeLogEntry&) @ 0x0000000015eba91b 20. /build/src/Storages/StorageReplicatedMergeTree.cpp:3876: bool std::__function::__policy_invoker&)>::__call_impl[abi:se190107])::$_1, bool (std::shared_ptr&)>>(std::__function::__policy_storage const*, std::shared_ptr&) @ 0x0000000015f9837e 21. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000165d6fc3 22. /build/src/Storages/StorageReplicatedMergeTree.cpp:3872: DB::StorageReplicatedMergeTree::processQueueEntry(std::shared_ptr) @ 0x0000000015efc18a 23. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001624c1b2 24. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000162f9c70 25. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x00000000162fa55a 26. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc6653 27. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000000fccc4c3 28. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc3d92 29. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fcca080 30. ? @ 0x00007fbc6213eac3 31. ? @ 0x00007fbc621d0850 (version 25.3.6.10636.altinitytest (altinity build)) 2025.07.28 12:02:39.270105 [ 5879 ] {d28a31bb-3c56-4f7d-bd76-9dfca3f5183c} executeQuery: Code: 388. DB::Exception: Cannot OPTIMIZE table: There are no parts inside partition. (CANNOT_ASSIGN_OPTIMIZE) (version 25.3.6.10636.altinitytest (altinity build)) (from [::1]:56488) (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. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x000000000a080b2b 4. /build/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) @ 0x0000000016648805 5. /build/src/Interpreters/InterpreterOptimizeQuery.cpp:84: DB::InterpreterOptimizeQuery::execute() @ 0x0000000014cd782e 6. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88dc9 7. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 8. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 9. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 10. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 11. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 12. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 13. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 14. ? @ 0x00007fbc6213eac3 15. ? @ 0x00007fbc621d0850 2025.07.28 12:02:39.355618 [ 5879 ] {} 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. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x000000000a080b2b 4. /build/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) @ 0x0000000016648805 5. /build/src/Interpreters/InterpreterOptimizeQuery.cpp:84: DB::InterpreterOptimizeQuery::execute() @ 0x0000000014cd782e 6. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88dc9 7. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 8. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 9. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 10. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 11. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 12. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 13. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 14. ? @ 0x00007fbc6213eac3 15. ? @ 0x00007fbc621d0850 2025.07.28 12:02:39.596972 [ 17203 ] {c2cc8d98-d2d6-43e7-8f50-2d0330a14945} executeQuery: Code: 60. DB::Exception: Table test_5.test_optimize_exception_replicated does not exist. Maybe you meant test_5.test_optimize_exception?. (UNKNOWN_TABLE) (version 25.3.6.10636.altinitytest (altinity build)) (from [::1]:56520) (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. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/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&&) @ 0x000000000a1011eb 4. /build/src/Databases/IDatabase.cpp:42: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x0000000013dd57aa 5. /build/src/Interpreters/DatabaseCatalog.cpp:442: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x00000000144f0869 6. /build/src/Interpreters/DatabaseCatalog.cpp:976: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x00000000144f6c88 7. /build/src/Interpreters/InterpreterOptimizeQuery.cpp:40: DB::InterpreterOptimizeQuery::execute() @ 0x0000000014cd71de 8. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88dc9 9. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 10. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 11. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 12. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 13. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 14. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 15. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 16. ? @ 0x00007fbc6213eac3 17. ? @ 0x00007fbc621d0850 2025.07.28 12:02:39.616715 [ 17203 ] {} TCPHandler: Code: 60. DB::Exception: Table test_5.test_optimize_exception_replicated does not exist. Maybe you meant test_5.test_optimize_exception?. (UNKNOWN_TABLE), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/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&&) @ 0x000000000a1011eb 4. /build/src/Databases/IDatabase.cpp:42: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x0000000013dd57aa 5. /build/src/Interpreters/DatabaseCatalog.cpp:442: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x00000000144f0869 6. /build/src/Interpreters/DatabaseCatalog.cpp:976: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x00000000144f6c88 7. /build/src/Interpreters/InterpreterOptimizeQuery.cpp:40: DB::InterpreterOptimizeQuery::execute() @ 0x0000000014cd71de 8. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88dc9 9. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 10. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 11. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 12. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 13. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 14. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 15. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 16. ? @ 0x00007fbc6213eac3 17. ? @ 0x00007fbc621d0850 2025.07.28 12:02:39.771385 [ 62053 ] {5b006659-925e-470b-9f24-cb2e792fbf4f} executeQuery: Code: 131. DB::Exception: String size is too big (2147483648), maximum: 2147483647: while executing 'FUNCTION CAST(concat(_CAST('ÿÿÿ'_String, 'String'_String), randomString(100500_UInt32)) :: 2, 'AggregateFunction(max, String)'_String :: 3) -> CAST(concat(_CAST('ÿÿÿ'_String, 'String'_String), randomString(100500_UInt32)), 'AggregateFunction(max, String)'_String) AggregateFunction(max, String) : 4'. (TOO_LARGE_STRING_SIZE) (version 25.3.6.10636.altinitytest (altinity build)) (from [::1]:55244) (comment: 02477_single_value_data_string_regression.sql) (query 26, line 93) (in query: SELECT '2^31-1', maxMerge(x) from (select CAST(unhex('ffffff7f') || randomString(100500), 'AggregateFunction(max, String)') as x);), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, unsigned int&, unsigned int const&) @ 0x0000000010a2dfeb 4. /build/src/AggregateFunctions/SingleValueData.cpp:1136: DB::SingleValueDataString::allocateLargeDataIfNeeded(unsigned int, DB::Arena*) @ 0x00000000109fac82 5. /build/src/AggregateFunctions/SingleValueData.cpp:1214: DB::SingleValueDataString::read(DB::ReadBuffer&, DB::ISerialization const&, std::shared_ptr const&, DB::Arena*) @ 0x00000000109fb13a 6. /build/src/DataTypes/Serializations/SerializationAggregateFunction.cpp:109: DB::deserializeFromString(std::shared_ptr const&, DB::IColumn&, String const&, unsigned long) @ 0x0000000013c80fde 7. /build/src/DataTypes/Serializations/SerializationAggregateFunction.cpp:158: DB::SerializationAggregateFunction::deserializeWholeText(DB::IColumn&, DB::ReadBuffer&, DB::FormatSettings const&) const @ 0x0000000013c8123e 8. /build/src/Functions/FunctionsConversion.h:1922: 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&) @ 0x0000000012de920b 9. /build/src/Functions/FunctionsConversion.h:1894: DB::detail::ConvertImplGenericFromString::execute(std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long, std::shared_ptr const&) @ 0x0000000012de7d2d 10. /build/src/Functions/FunctionsConversion.h:3821: COW::immutable_ptr std::__function::__policy_invoker::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)>::__call_impl[abi:se190107] 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) @ 0x0000000012f96541 11. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000012ddcb1b 12. /build/src/Functions/IFunction.cpp:353: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d93b52 13. /build/src/Functions/IFunction.cpp:424: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d94e1b 14. /build/src/Functions/IFunction.cpp:498: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d95c72 15. /build/src/Interpreters/ExpressionActions.cpp:636: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x00000000145176f3 16. /build/src/Processors/Transforms/ExpressionTransform.cpp:25: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x0000000016c0b34c 17. /build/src/Processors/ISimpleTransform.h:33: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000011a9a453 18. /build/src/Processors/ISimpleTransform.cpp:89: DB::ISimpleTransform::work() @ 0x000000001699fca0 19. /build/src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x00000000169bd00f 20. /build/src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x00000000169b2105 21. /build/src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeSingleThread(unsigned long) @ 0x00000000169b23be 22. /build/src/Processors/Executors/PipelineExecutor.cpp:454: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x00000000169b0be7 23. /build/src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x00000000169b03f4 24. /build/src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:se190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169bfeab 25. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc3d92 26. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fcca080 27. ? @ 0x00007fbc6213eac3 28. ? @ 0x00007fbc621d0850 2025.07.28 12:02:39.779019 [ 62053 ] {} TCPHandler: Code: 131. DB::Exception: String size is too big (2147483648), maximum: 2147483647: while executing 'FUNCTION CAST(concat(_CAST('ÿÿÿ'_String, 'String'_String), randomString(100500_UInt32)) :: 2, 'AggregateFunction(max, String)'_String :: 3) -> CAST(concat(_CAST('ÿÿÿ'_String, 'String'_String), randomString(100500_UInt32)), 'AggregateFunction(max, String)'_String) AggregateFunction(max, String) : 4'. (TOO_LARGE_STRING_SIZE), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, unsigned int&, unsigned int const&) @ 0x0000000010a2dfeb 4. /build/src/AggregateFunctions/SingleValueData.cpp:1136: DB::SingleValueDataString::allocateLargeDataIfNeeded(unsigned int, DB::Arena*) @ 0x00000000109fac82 5. /build/src/AggregateFunctions/SingleValueData.cpp:1214: DB::SingleValueDataString::read(DB::ReadBuffer&, DB::ISerialization const&, std::shared_ptr const&, DB::Arena*) @ 0x00000000109fb13a 6. /build/src/DataTypes/Serializations/SerializationAggregateFunction.cpp:109: DB::deserializeFromString(std::shared_ptr const&, DB::IColumn&, String const&, unsigned long) @ 0x0000000013c80fde 7. /build/src/DataTypes/Serializations/SerializationAggregateFunction.cpp:158: DB::SerializationAggregateFunction::deserializeWholeText(DB::IColumn&, DB::ReadBuffer&, DB::FormatSettings const&) const @ 0x0000000013c8123e 8. /build/src/Functions/FunctionsConversion.h:1922: 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&) @ 0x0000000012de920b 9. /build/src/Functions/FunctionsConversion.h:1894: DB::detail::ConvertImplGenericFromString::execute(std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long, std::shared_ptr const&) @ 0x0000000012de7d2d 10. /build/src/Functions/FunctionsConversion.h:3821: COW::immutable_ptr std::__function::__policy_invoker::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)>::__call_impl[abi:se190107] 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) @ 0x0000000012f96541 11. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000012ddcb1b 12. /build/src/Functions/IFunction.cpp:353: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d93b52 13. /build/src/Functions/IFunction.cpp:424: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d94e1b 14. /build/src/Functions/IFunction.cpp:498: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d95c72 15. /build/src/Interpreters/ExpressionActions.cpp:636: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x00000000145176f3 16. /build/src/Processors/Transforms/ExpressionTransform.cpp:25: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x0000000016c0b34c 17. /build/src/Processors/ISimpleTransform.h:33: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000011a9a453 18. /build/src/Processors/ISimpleTransform.cpp:89: DB::ISimpleTransform::work() @ 0x000000001699fca0 19. /build/src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x00000000169bd00f 20. /build/src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x00000000169b2105 21. /build/src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeSingleThread(unsigned long) @ 0x00000000169b23be 22. /build/src/Processors/Executors/PipelineExecutor.cpp:454: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x00000000169b0be7 23. /build/src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x00000000169b03f4 24. /build/src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:se190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169bfeab 25. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc3d92 26. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fcca080 27. ? @ 0x00007fbc6213eac3 28. ? @ 0x00007fbc621d0850 Job's origin stack trace: 0. /build/src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000000fc33b84 1. /build/src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000000fcc2ea7 2. /build/src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fcc535c 3. /build/src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000000fcc584d 4. /build/src/Common/ThreadPool.h:279: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x00000000169bf193 5. /build/src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x00000000169bf518 6. /build/src/Server/TCPHandler.cpp:1237: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x00000000168f1525 7. /build/src/Server/TCPHandler.cpp:678: DB::TCPHandler::runImpl() @ 0x00000000168e68e5 8. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 9. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 10. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 11. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 12. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 13. ? @ 0x00007fbc6213eac3 14. ? @ 0x00007fbc621d0850 2025.07.28 12:02:40.065658 [ 62053 ] {06d83171-2fbf-49e6-bcf2-a3e6c9f1055d} executeQuery: Code: 33. DB::Exception: Cannot read all data. Bytes read: 100500. Bytes expected: 2147483646.: while executing 'FUNCTION CAST(concat(_CAST('þÿÿ'_String, 'String'_String), randomString(100500_UInt32)) :: 2, 'AggregateFunction(max, String)'_String :: 3) -> CAST(concat(_CAST('þÿÿ'_String, 'String'_String), randomString(100500_UInt32)), 'AggregateFunction(max, String)'_String) AggregateFunction(max, String) : 4'. (CANNOT_READ_ALL_DATA) (version 25.3.6.10636.altinitytest (altinity build)) (from [::1]:55244) (comment: 02477_single_value_data_string_regression.sql) (query 27, line 95) (in query: SELECT '2^31-2', maxMerge(x) from (select CAST(unhex('feffff7f') || randomString(100500), 'AggregateFunction(max, String)') as x);), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, unsigned long&, String&&) @ 0x000000000ba5db6b 4. /build/src/IO/ReadBuffer.cpp:49: DB::ReadBuffer::readStrict(char*, unsigned long) @ 0x000000000fc66ec7 5. /build/src/AggregateFunctions/SingleValueData.cpp:0: DB::SingleValueDataString::read(DB::ReadBuffer&, DB::ISerialization const&, std::shared_ptr const&, DB::Arena*) @ 0x00000000109fb14d 6. /build/src/DataTypes/Serializations/SerializationAggregateFunction.cpp:109: DB::deserializeFromString(std::shared_ptr const&, DB::IColumn&, String const&, unsigned long) @ 0x0000000013c80fde 7. /build/src/DataTypes/Serializations/SerializationAggregateFunction.cpp:158: DB::SerializationAggregateFunction::deserializeWholeText(DB::IColumn&, DB::ReadBuffer&, DB::FormatSettings const&) const @ 0x0000000013c8123e 8. /build/src/Functions/FunctionsConversion.h:1922: 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&) @ 0x0000000012de920b 9. /build/src/Functions/FunctionsConversion.h:1894: DB::detail::ConvertImplGenericFromString::execute(std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long, std::shared_ptr const&) @ 0x0000000012de7d2d 10. /build/src/Functions/FunctionsConversion.h:3821: COW::immutable_ptr std::__function::__policy_invoker::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)>::__call_impl[abi:se190107] 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) @ 0x0000000012f96541 11. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000012ddcb1b 12. /build/src/Functions/IFunction.cpp:353: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d93b52 13. /build/src/Functions/IFunction.cpp:424: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d94e1b 14. /build/src/Functions/IFunction.cpp:498: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d95c72 15. /build/src/Interpreters/ExpressionActions.cpp:636: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x00000000145176f3 16. /build/src/Processors/Transforms/ExpressionTransform.cpp:25: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x0000000016c0b34c 17. /build/src/Processors/ISimpleTransform.h:33: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000011a9a453 18. /build/src/Processors/ISimpleTransform.cpp:89: DB::ISimpleTransform::work() @ 0x000000001699fca0 19. /build/src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x00000000169bd00f 20. /build/src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x00000000169b2105 21. /build/src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeSingleThread(unsigned long) @ 0x00000000169b23be 22. /build/src/Processors/Executors/PipelineExecutor.cpp:454: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x00000000169b0be7 23. /build/src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x00000000169b03f4 24. /build/src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:se190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169bfeab 25. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc3d92 26. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fcca080 27. ? @ 0x00007fbc6213eac3 28. ? @ 0x00007fbc621d0850 2025.07.28 12:02:40.069701 [ 17203 ] {458773e0-3992-404e-a695-82b51e9de25a} executeQuery: Code: 60. DB::Exception: Table test_5.test_optimize_exception_replicated does not exist. Maybe you meant test_5.test_optimize_exception?. (UNKNOWN_TABLE) (version 25.3.6.10636.altinitytest (altinity build)) (from [::1]:56556) (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. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/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&&) @ 0x000000000a1011eb 4. /build/src/Databases/IDatabase.cpp:42: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x0000000013dd57aa 5. /build/src/Interpreters/DatabaseCatalog.cpp:442: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x00000000144f0869 6. /build/src/Interpreters/DatabaseCatalog.cpp:990: DB::DatabaseCatalog::getDatabaseAndTable(DB::StorageID const&, std::shared_ptr) const @ 0x00000000144f6e1d 7. /build/src/Interpreters/InterpreterDropQuery.cpp:146: DB::InterpreterDropQuery::executeToTableImpl(std::shared_ptr const&, DB::ASTDropQuery&, std::shared_ptr&, StrongTypedef, DB::UUIDTag>&) @ 0x00000000149140bf 8. /build/src/Interpreters/InterpreterDropQuery.cpp:118: DB::InterpreterDropQuery::executeToTable(DB::ASTDropQuery&) @ 0x00000000149137b4 9. /build/src/Interpreters/InterpreterDropQuery.cpp:91: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000014912f07 10. /build/src/Interpreters/InterpreterDropQuery.cpp:72: DB::InterpreterDropQuery::execute() @ 0x0000000014912b65 11. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88dc9 12. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 13. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 14. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 15. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 16. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 17. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 18. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 19. ? @ 0x00007fbc6213eac3 20. ? @ 0x00007fbc621d0850 2025.07.28 12:02:40.100278 [ 17203 ] {} TCPHandler: Code: 60. DB::Exception: Table test_5.test_optimize_exception_replicated does not exist. Maybe you meant test_5.test_optimize_exception?. (UNKNOWN_TABLE), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/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&&) @ 0x000000000a1011eb 4. /build/src/Databases/IDatabase.cpp:42: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x0000000013dd57aa 5. /build/src/Interpreters/DatabaseCatalog.cpp:442: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x00000000144f0869 6. /build/src/Interpreters/DatabaseCatalog.cpp:990: DB::DatabaseCatalog::getDatabaseAndTable(DB::StorageID const&, std::shared_ptr) const @ 0x00000000144f6e1d 7. /build/src/Interpreters/InterpreterDropQuery.cpp:146: DB::InterpreterDropQuery::executeToTableImpl(std::shared_ptr const&, DB::ASTDropQuery&, std::shared_ptr&, StrongTypedef, DB::UUIDTag>&) @ 0x00000000149140bf 8. /build/src/Interpreters/InterpreterDropQuery.cpp:118: DB::InterpreterDropQuery::executeToTable(DB::ASTDropQuery&) @ 0x00000000149137b4 9. /build/src/Interpreters/InterpreterDropQuery.cpp:91: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000014912f07 10. /build/src/Interpreters/InterpreterDropQuery.cpp:72: DB::InterpreterDropQuery::execute() @ 0x0000000014912b65 11. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88dc9 12. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 13. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 14. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 15. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 16. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 17. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 18. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 19. ? @ 0x00007fbc6213eac3 20. ? @ 0x00007fbc621d0850 2025.07.28 12:02:40.110331 [ 62053 ] {} TCPHandler: Code: 33. DB::Exception: Cannot read all data. Bytes read: 100500. Bytes expected: 2147483646.: while executing 'FUNCTION CAST(concat(_CAST('þÿÿ'_String, 'String'_String), randomString(100500_UInt32)) :: 2, 'AggregateFunction(max, String)'_String :: 3) -> CAST(concat(_CAST('þÿÿ'_String, 'String'_String), randomString(100500_UInt32)), 'AggregateFunction(max, String)'_String) AggregateFunction(max, String) : 4'. (CANNOT_READ_ALL_DATA), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, unsigned long&, String&&) @ 0x000000000ba5db6b 4. /build/src/IO/ReadBuffer.cpp:49: DB::ReadBuffer::readStrict(char*, unsigned long) @ 0x000000000fc66ec7 5. /build/src/AggregateFunctions/SingleValueData.cpp:0: DB::SingleValueDataString::read(DB::ReadBuffer&, DB::ISerialization const&, std::shared_ptr const&, DB::Arena*) @ 0x00000000109fb14d 6. /build/src/DataTypes/Serializations/SerializationAggregateFunction.cpp:109: DB::deserializeFromString(std::shared_ptr const&, DB::IColumn&, String const&, unsigned long) @ 0x0000000013c80fde 7. /build/src/DataTypes/Serializations/SerializationAggregateFunction.cpp:158: DB::SerializationAggregateFunction::deserializeWholeText(DB::IColumn&, DB::ReadBuffer&, DB::FormatSettings const&) const @ 0x0000000013c8123e 8. /build/src/Functions/FunctionsConversion.h:1922: 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&) @ 0x0000000012de920b 9. /build/src/Functions/FunctionsConversion.h:1894: DB::detail::ConvertImplGenericFromString::execute(std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long, std::shared_ptr const&) @ 0x0000000012de7d2d 10. /build/src/Functions/FunctionsConversion.h:3821: COW::immutable_ptr std::__function::__policy_invoker::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)>::__call_impl[abi:se190107] 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) @ 0x0000000012f96541 11. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000012ddcb1b 12. /build/src/Functions/IFunction.cpp:353: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d93b52 13. /build/src/Functions/IFunction.cpp:424: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d94e1b 14. /build/src/Functions/IFunction.cpp:498: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d95c72 15. /build/src/Interpreters/ExpressionActions.cpp:636: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x00000000145176f3 16. /build/src/Processors/Transforms/ExpressionTransform.cpp:25: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x0000000016c0b34c 17. /build/src/Processors/ISimpleTransform.h:33: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000011a9a453 18. /build/src/Processors/ISimpleTransform.cpp:89: DB::ISimpleTransform::work() @ 0x000000001699fca0 19. /build/src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x00000000169bd00f 20. /build/src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x00000000169b2105 21. /build/src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeSingleThread(unsigned long) @ 0x00000000169b23be 22. /build/src/Processors/Executors/PipelineExecutor.cpp:454: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x00000000169b0be7 23. /build/src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x00000000169b03f4 24. /build/src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:se190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169bfeab 25. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc3d92 26. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fcca080 27. ? @ 0x00007fbc6213eac3 28. ? @ 0x00007fbc621d0850 Job's origin stack trace: 0. /build/src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000000fc33b84 1. /build/src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000000fcc2ea7 2. /build/src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fcc535c 3. /build/src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000000fcc584d 4. /build/src/Common/ThreadPool.h:279: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x00000000169bf193 5. /build/src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x00000000169bf518 6. /build/src/Server/TCPHandler.cpp:1237: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x00000000168f1525 7. /build/src/Server/TCPHandler.cpp:678: DB::TCPHandler::runImpl() @ 0x00000000168e68e5 8. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 9. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 10. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 11. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 12. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 13. ? @ 0x00007fbc6213eac3 14. ? @ 0x00007fbc621d0850 2025.07.28 12:02:40.182303 [ 62053 ] {5f37b751-fd25-4825-8221-df7f80ba5577} executeQuery: Code: 33. DB::Exception: Cannot read all data. Bytes read: 100500. Bytes expected: 1073741824.: while executing 'FUNCTION CAST(concat(_CAST('\0\0\0@'_String, 'String'_String), randomString(100500_UInt32)) :: 2, 'AggregateFunction(max, String)'_String :: 3) -> CAST(concat(_CAST('\0\0\0@'_String, 'String'_String), randomString(100500_UInt32)), 'AggregateFunction(max, String)'_String) AggregateFunction(max, String) : 4'. (CANNOT_READ_ALL_DATA) (version 25.3.6.10636.altinitytest (altinity build)) (from [::1]:55244) (comment: 02477_single_value_data_string_regression.sql) (query 28, line 97) (in query: SELECT '2^30', maxMerge(x) from (select CAST(unhex('00000040') || randomString(100500), 'AggregateFunction(max, String)') as x);), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, unsigned long&, String&&) @ 0x000000000ba5db6b 4. /build/src/IO/ReadBuffer.cpp:49: DB::ReadBuffer::readStrict(char*, unsigned long) @ 0x000000000fc66ec7 5. /build/src/AggregateFunctions/SingleValueData.cpp:0: DB::SingleValueDataString::read(DB::ReadBuffer&, DB::ISerialization const&, std::shared_ptr const&, DB::Arena*) @ 0x00000000109fb14d 6. /build/src/DataTypes/Serializations/SerializationAggregateFunction.cpp:109: DB::deserializeFromString(std::shared_ptr const&, DB::IColumn&, String const&, unsigned long) @ 0x0000000013c80fde 7. /build/src/DataTypes/Serializations/SerializationAggregateFunction.cpp:158: DB::SerializationAggregateFunction::deserializeWholeText(DB::IColumn&, DB::ReadBuffer&, DB::FormatSettings const&) const @ 0x0000000013c8123e 8. /build/src/Functions/FunctionsConversion.h:1922: 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&) @ 0x0000000012de920b 9. /build/src/Functions/FunctionsConversion.h:1894: DB::detail::ConvertImplGenericFromString::execute(std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long, std::shared_ptr const&) @ 0x0000000012de7d2d 10. /build/src/Functions/FunctionsConversion.h:3821: COW::immutable_ptr std::__function::__policy_invoker::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)>::__call_impl[abi:se190107] 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) @ 0x0000000012f96541 11. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000012ddcb1b 12. /build/src/Functions/IFunction.cpp:353: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d93b52 13. /build/src/Functions/IFunction.cpp:424: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d94e1b 14. /build/src/Functions/IFunction.cpp:498: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d95c72 15. /build/src/Interpreters/ExpressionActions.cpp:636: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x00000000145176f3 16. /build/src/Processors/Transforms/ExpressionTransform.cpp:25: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x0000000016c0b34c 17. /build/src/Processors/ISimpleTransform.h:33: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000011a9a453 18. /build/src/Processors/ISimpleTransform.cpp:89: DB::ISimpleTransform::work() @ 0x000000001699fca0 19. /build/src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x00000000169bd00f 20. /build/src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x00000000169b2105 21. /build/src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeSingleThread(unsigned long) @ 0x00000000169b23be 22. /build/src/Processors/Executors/PipelineExecutor.cpp:454: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x00000000169b0be7 23. /build/src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x00000000169b03f4 24. /build/src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:se190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169bfeab 25. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc3d92 26. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fcca080 27. ? @ 0x00007fbc6213eac3 28. ? @ 0x00007fbc621d0850 2025.07.28 12:02:40.208427 [ 62053 ] {} TCPHandler: Code: 33. DB::Exception: Cannot read all data. Bytes read: 100500. Bytes expected: 1073741824.: while executing 'FUNCTION CAST(concat(_CAST('\0\0\0@'_String, 'String'_String), randomString(100500_UInt32)) :: 2, 'AggregateFunction(max, String)'_String :: 3) -> CAST(concat(_CAST('\0\0\0@'_String, 'String'_String), randomString(100500_UInt32)), 'AggregateFunction(max, String)'_String) AggregateFunction(max, String) : 4'. (CANNOT_READ_ALL_DATA), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, unsigned long&, String&&) @ 0x000000000ba5db6b 4. /build/src/IO/ReadBuffer.cpp:49: DB::ReadBuffer::readStrict(char*, unsigned long) @ 0x000000000fc66ec7 5. /build/src/AggregateFunctions/SingleValueData.cpp:0: DB::SingleValueDataString::read(DB::ReadBuffer&, DB::ISerialization const&, std::shared_ptr const&, DB::Arena*) @ 0x00000000109fb14d 6. /build/src/DataTypes/Serializations/SerializationAggregateFunction.cpp:109: DB::deserializeFromString(std::shared_ptr const&, DB::IColumn&, String const&, unsigned long) @ 0x0000000013c80fde 7. /build/src/DataTypes/Serializations/SerializationAggregateFunction.cpp:158: DB::SerializationAggregateFunction::deserializeWholeText(DB::IColumn&, DB::ReadBuffer&, DB::FormatSettings const&) const @ 0x0000000013c8123e 8. /build/src/Functions/FunctionsConversion.h:1922: 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&) @ 0x0000000012de920b 9. /build/src/Functions/FunctionsConversion.h:1894: DB::detail::ConvertImplGenericFromString::execute(std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long, std::shared_ptr const&) @ 0x0000000012de7d2d 10. /build/src/Functions/FunctionsConversion.h:3821: COW::immutable_ptr std::__function::__policy_invoker::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)>::__call_impl[abi:se190107] 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) @ 0x0000000012f96541 11. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000012ddcb1b 12. /build/src/Functions/IFunction.cpp:353: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d93b52 13. /build/src/Functions/IFunction.cpp:424: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d94e1b 14. /build/src/Functions/IFunction.cpp:498: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d95c72 15. /build/src/Interpreters/ExpressionActions.cpp:636: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x00000000145176f3 16. /build/src/Processors/Transforms/ExpressionTransform.cpp:25: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x0000000016c0b34c 17. /build/src/Processors/ISimpleTransform.h:33: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000011a9a453 18. /build/src/Processors/ISimpleTransform.cpp:89: DB::ISimpleTransform::work() @ 0x000000001699fca0 19. /build/src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x00000000169bd00f 20. /build/src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x00000000169b2105 21. /build/src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeSingleThread(unsigned long) @ 0x00000000169b23be 22. /build/src/Processors/Executors/PipelineExecutor.cpp:454: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x00000000169b0be7 23. /build/src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x00000000169b03f4 24. /build/src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:se190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169bfeab 25. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc3d92 26. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fcca080 27. ? @ 0x00007fbc6213eac3 28. ? @ 0x00007fbc621d0850 Job's origin stack trace: 0. /build/src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000000fc33b84 1. /build/src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000000fcc2ea7 2. /build/src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fcc535c 3. /build/src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000000fcc584d 4. /build/src/Common/ThreadPool.h:279: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x00000000169bf193 5. /build/src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x00000000169bf518 6. /build/src/Server/TCPHandler.cpp:1237: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x00000000168f1525 7. /build/src/Server/TCPHandler.cpp:678: DB::TCPHandler::runImpl() @ 0x00000000168e68e5 8. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 9. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 10. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 11. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 12. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 13. ? @ 0x00007fbc6213eac3 14. ? @ 0x00007fbc621d0850 2025.07.28 12:02:40.212882 [ 4900 ] {} 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. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception>&, String>(int, FormatStringHelperImpl>&>::type, std::type_identity::type>, std::basic_string_view>&, String&&) @ 0x000000001385a5eb 4. /build/src/Access/SettingsConstraints.cpp:376: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000013859b18 5. /build/src/Access/SettingsConstraints.cpp:300: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000013858faf 6. /build/src/Access/SettingsConstraints.cpp:209: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000013859223 7. /build/src/Interpreters/Context.cpp:2690: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000014436134 8. /build/src/Interpreters/Context.cpp:2729: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x000000001443662b 9. /build/src/Server/HTTPHandler.cpp:457: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000001686d165 10. /build/src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x0000000016870807 11. /build/src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x0000000016907e99 12. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 13. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 14. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 15. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 16. ? @ 0x00007fbc6213eac3 17. ? @ 0x00007fbc621d0850 (version 25.3.6.10636.altinitytest (altinity build)) 2025.07.28 12:02:40.319874 [ 3972 ] {} test_13.rmt2 (7f9b740d-015c-470e-8cc6-8ba33be0dc63): auto DB::StorageReplicatedMergeTree::processQueueEntry(ReplicatedMergeTreeQueue::SelectedEntryPtr)::(anonymous class)::operator()(LogEntryPtr &) const: Code: 86. DB::HTTPException: Received error from remote server http://146b4357c08d:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Ftest%2F01165%2Ftest_13%2Frmt%2Freplicas%2F1&part=20250728_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.6.10636.altinitytest (altinity build)) '. (RECEIVED_ERROR_FROM_REMOTE_IO_SERVER), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.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 const&, int&&, String const&, unsigned long&&, String const&) @ 0x000000000feda8d9 4. /build/src/IO/HTTPCommon.cpp:104: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x000000000feda6e2 5. /build/src/IO/HTTPCommon.cpp:93: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x000000000feda537 6. /build/src/IO/ReadWriteBufferFromHTTP.cpp:277: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x000000001184a4c4 7. /build/src/IO/ReadWriteBufferFromHTTP.cpp:285: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x000000001184a615 8. /build/src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x000000001184ae59 9. /build/src/IO/ReadWriteBufferFromHTTP.cpp:472: void std::__function::__policy_invoker::__call_impl[abi:se190107]>(std::__function::__policy_storage const*) @ 0x000000001184cedd 10. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001184858b 11. /build/src/IO/ReadWriteBufferFromHTTP.cpp:465: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x000000001184bf0b 12. /build/src/IO/ReadBuffer.h:60: DB::ReadBuffer::next() @ 0x000000000a148c7b 13. /build/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) @ 0x0000000011849fb2 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]>&)>&, 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&) @ 0x0000000011841980 15. /build/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) @ 0x000000001621208e 16. /build/src/Storages/StorageReplicatedMergeTree.cpp:5228: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl[abi:se190107] const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000015f9a5fe 17. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000015ed8bfd 18. /build/src/Storages/StorageReplicatedMergeTree.cpp:2514: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x0000000015ec9aab 19. /build/src/Storages/StorageReplicatedMergeTree.cpp:2349: DB::StorageReplicatedMergeTree::executeLogEntry(DB::ReplicatedMergeTreeLogEntry&) @ 0x0000000015eba91b 20. /build/src/Storages/StorageReplicatedMergeTree.cpp:3876: bool std::__function::__policy_invoker&)>::__call_impl[abi:se190107])::$_1, bool (std::shared_ptr&)>>(std::__function::__policy_storage const*, std::shared_ptr&) @ 0x0000000015f9837e 21. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000165d6fc3 22. /build/src/Storages/StorageReplicatedMergeTree.cpp:3872: DB::StorageReplicatedMergeTree::processQueueEntry(std::shared_ptr) @ 0x0000000015efc18a 23. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001624c1b2 24. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000162f9c70 25. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x00000000162fa55a 26. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc6653 27. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000000fccc4c3 28. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc3d92 29. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fcca080 30. ? @ 0x00007fbc6213eac3 31. ? @ 0x00007fbc621d0850 (version 25.3.6.10636.altinitytest (altinity build)) 2025.07.28 12:02:40.406464 [ 62053 ] {63cda137-162c-471c-bbaa-19d78c4cb6b0} executeQuery: Code: 33. DB::Exception: Cannot read all data. Bytes read: 100500. Bytes expected: 1073741825.: while executing 'FUNCTION CAST(concat(_CAST('\0\0@'_String, 'String'_String), randomString(100500_UInt32)) :: 2, 'AggregateFunction(max, String)'_String :: 3) -> CAST(concat(_CAST('\0\0@'_String, 'String'_String), randomString(100500_UInt32)), 'AggregateFunction(max, String)'_String) AggregateFunction(max, String) : 4'. (CANNOT_READ_ALL_DATA) (version 25.3.6.10636.altinitytest (altinity build)) (from [::1]:55244) (comment: 02477_single_value_data_string_regression.sql) (query 29, line 98) (in query: SELECT '2^30+1', maxMerge(x) from (select CAST(unhex('01000040') || randomString(100500), 'AggregateFunction(max, String)') as x);), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, unsigned long&, String&&) @ 0x000000000ba5db6b 4. /build/src/IO/ReadBuffer.cpp:49: DB::ReadBuffer::readStrict(char*, unsigned long) @ 0x000000000fc66ec7 5. /build/src/AggregateFunctions/SingleValueData.cpp:0: DB::SingleValueDataString::read(DB::ReadBuffer&, DB::ISerialization const&, std::shared_ptr const&, DB::Arena*) @ 0x00000000109fb14d 6. /build/src/DataTypes/Serializations/SerializationAggregateFunction.cpp:109: DB::deserializeFromString(std::shared_ptr const&, DB::IColumn&, String const&, unsigned long) @ 0x0000000013c80fde 7. /build/src/DataTypes/Serializations/SerializationAggregateFunction.cpp:158: DB::SerializationAggregateFunction::deserializeWholeText(DB::IColumn&, DB::ReadBuffer&, DB::FormatSettings const&) const @ 0x0000000013c8123e 8. /build/src/Functions/FunctionsConversion.h:1922: 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&) @ 0x0000000012de920b 9. /build/src/Functions/FunctionsConversion.h:1894: DB::detail::ConvertImplGenericFromString::execute(std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long, std::shared_ptr const&) @ 0x0000000012de7d2d 10. /build/src/Functions/FunctionsConversion.h:3821: COW::immutable_ptr std::__function::__policy_invoker::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)>::__call_impl[abi:se190107] 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) @ 0x0000000012f96541 11. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000012ddcb1b 12. /build/src/Functions/IFunction.cpp:353: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d93b52 13. /build/src/Functions/IFunction.cpp:424: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d94e1b 14. /build/src/Functions/IFunction.cpp:498: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d95c72 15. /build/src/Interpreters/ExpressionActions.cpp:636: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x00000000145176f3 16. /build/src/Processors/Transforms/ExpressionTransform.cpp:25: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x0000000016c0b34c 17. /build/src/Processors/ISimpleTransform.h:33: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000011a9a453 18. /build/src/Processors/ISimpleTransform.cpp:89: DB::ISimpleTransform::work() @ 0x000000001699fca0 19. /build/src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x00000000169bd00f 20. /build/src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x00000000169b2105 21. /build/src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeSingleThread(unsigned long) @ 0x00000000169b23be 22. /build/src/Processors/Executors/PipelineExecutor.cpp:454: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x00000000169b0be7 23. /build/src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x00000000169b03f4 24. /build/src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:se190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169bfeab 25. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc3d92 26. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fcca080 27. ? @ 0x00007fbc6213eac3 28. ? @ 0x00007fbc621d0850 2025.07.28 12:02:40.410606 [ 62053 ] {} TCPHandler: Code: 33. DB::Exception: Cannot read all data. Bytes read: 100500. Bytes expected: 1073741825.: while executing 'FUNCTION CAST(concat(_CAST('\0\0@'_String, 'String'_String), randomString(100500_UInt32)) :: 2, 'AggregateFunction(max, String)'_String :: 3) -> CAST(concat(_CAST('\0\0@'_String, 'String'_String), randomString(100500_UInt32)), 'AggregateFunction(max, String)'_String) AggregateFunction(max, String) : 4'. (CANNOT_READ_ALL_DATA), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, unsigned long&, String&&) @ 0x000000000ba5db6b 4. /build/src/IO/ReadBuffer.cpp:49: DB::ReadBuffer::readStrict(char*, unsigned long) @ 0x000000000fc66ec7 5. /build/src/AggregateFunctions/SingleValueData.cpp:0: DB::SingleValueDataString::read(DB::ReadBuffer&, DB::ISerialization const&, std::shared_ptr const&, DB::Arena*) @ 0x00000000109fb14d 6. /build/src/DataTypes/Serializations/SerializationAggregateFunction.cpp:109: DB::deserializeFromString(std::shared_ptr const&, DB::IColumn&, String const&, unsigned long) @ 0x0000000013c80fde 7. /build/src/DataTypes/Serializations/SerializationAggregateFunction.cpp:158: DB::SerializationAggregateFunction::deserializeWholeText(DB::IColumn&, DB::ReadBuffer&, DB::FormatSettings const&) const @ 0x0000000013c8123e 8. /build/src/Functions/FunctionsConversion.h:1922: 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&) @ 0x0000000012de920b 9. /build/src/Functions/FunctionsConversion.h:1894: DB::detail::ConvertImplGenericFromString::execute(std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long, std::shared_ptr const&) @ 0x0000000012de7d2d 10. /build/src/Functions/FunctionsConversion.h:3821: COW::immutable_ptr std::__function::__policy_invoker::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)>::__call_impl[abi:se190107] 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) @ 0x0000000012f96541 11. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000012ddcb1b 12. /build/src/Functions/IFunction.cpp:353: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d93b52 13. /build/src/Functions/IFunction.cpp:424: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d94e1b 14. /build/src/Functions/IFunction.cpp:498: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d95c72 15. /build/src/Interpreters/ExpressionActions.cpp:636: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x00000000145176f3 16. /build/src/Processors/Transforms/ExpressionTransform.cpp:25: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x0000000016c0b34c 17. /build/src/Processors/ISimpleTransform.h:33: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000011a9a453 18. /build/src/Processors/ISimpleTransform.cpp:89: DB::ISimpleTransform::work() @ 0x000000001699fca0 19. /build/src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x00000000169bd00f 20. /build/src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x00000000169b2105 21. /build/src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeSingleThread(unsigned long) @ 0x00000000169b23be 22. /build/src/Processors/Executors/PipelineExecutor.cpp:454: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x00000000169b0be7 23. /build/src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x00000000169b03f4 24. /build/src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:se190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169bfeab 25. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc3d92 26. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fcca080 27. ? @ 0x00007fbc6213eac3 28. ? @ 0x00007fbc621d0850 Job's origin stack trace: 0. /build/src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000000fc33b84 1. /build/src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000000fcc2ea7 2. /build/src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fcc535c 3. /build/src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000000fcc584d 4. /build/src/Common/ThreadPool.h:279: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x00000000169bf193 5. /build/src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x00000000169bf518 6. /build/src/Server/TCPHandler.cpp:1237: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x00000000168f1525 7. /build/src/Server/TCPHandler.cpp:678: DB::TCPHandler::runImpl() @ 0x00000000168e68e5 8. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 9. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 10. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 11. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 12. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 13. ? @ 0x00007fbc6213eac3 14. ? @ 0x00007fbc621d0850 2025.07.28 12:02:40.413123 [ 17203 ] {2bc412f7-12bb-4d6d-a128-1e84a5295ec0} executeQuery: Code: 43. DB::Exception: Argument 'max_width' must not be NaN: In scope SELECT bar((greatCircleAngle(65537, 2, 1, 1) - 1) * 65535, 1048576, 1048577, nan). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.6.10636.altinitytest (altinity build)) (from [::1]:56578) (comment: 01621_bar_nan_arguments.sql) (query 1, line 1) (in query: SELECT bar((greatCircleAngle(65537, 2, 1, 1) - 1) * 65535, 1048576, 1048577, nan);), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000000a074fcb 4. /build/src/Functions/bar.cpp:91: DB::(anonymous namespace)::FunctionBar::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000aad93b9 5. /build/src/Functions/IFunction.h:437: DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000a069f2a 6. /build/src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000012d9965a 7. /build/src/Functions/IFunction.cpp:351: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d93b02 8. /build/src/Functions/IFunction.cpp:177: DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d93698 9. /build/src/Functions/IFunction.cpp:343: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d93aad 10. /build/src/Functions/IFunction.cpp:420: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d95059 11. /build/src/Functions/IFunction.cpp:498: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d95c72 12. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3567: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000014034494 13. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3838: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000014019a9e 14. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3980: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000014018e31 15. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:4304: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000014042fa7 16. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5605: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000014013749 17. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000140127f9 18. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000014011fce 19. /build/src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000001406ce8a 20. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000014973b42 21. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000001497268d 22. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000014974d24 23. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001492924b 24. /build/src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88641 25. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 26. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 27. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 28. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 29. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 30. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 31. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 2025.07.28 12:02:40.421752 [ 17203 ] {} TCPHandler: Code: 43. DB::Exception: Argument 'max_width' must not be NaN: In scope SELECT bar((greatCircleAngle(65537, 2, 1, 1) - 1) * 65535, 1048576, 1048577, nan). (ILLEGAL_TYPE_OF_ARGUMENT), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000000a074fcb 4. /build/src/Functions/bar.cpp:91: DB::(anonymous namespace)::FunctionBar::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000aad93b9 5. /build/src/Functions/IFunction.h:437: DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000a069f2a 6. /build/src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000012d9965a 7. /build/src/Functions/IFunction.cpp:351: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d93b02 8. /build/src/Functions/IFunction.cpp:177: DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d93698 9. /build/src/Functions/IFunction.cpp:343: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d93aad 10. /build/src/Functions/IFunction.cpp:420: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d95059 11. /build/src/Functions/IFunction.cpp:498: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d95c72 12. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3567: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000014034494 13. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3838: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000014019a9e 14. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3980: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000014018e31 15. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:4304: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000014042fa7 16. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5605: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000014013749 17. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000140127f9 18. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000014011fce 19. /build/src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000001406ce8a 20. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000014973b42 21. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000001497268d 22. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000014974d24 23. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001492924b 24. /build/src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88641 25. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 26. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 27. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 28. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 29. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 30. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 31. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 2025.07.28 12:02:40.450709 [ 17203 ] {b4fb2636-e756-45ee-a4d2-19fb0eed66ef} executeQuery: Code: 43. DB::Exception: Argument 'max_width' must not be NaN: In scope SELECT bar(1, 1, 1, nan). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.6.10636.altinitytest (altinity build)) (from [::1]:56578) (comment: 01621_bar_nan_arguments.sql) (query 2, line 2) (in query: select bar(1,1,1,nan);), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000000a074fcb 4. /build/src/Functions/bar.cpp:91: DB::(anonymous namespace)::FunctionBar::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000aad93b9 5. /build/src/Functions/IFunction.h:437: DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000a069f2a 6. /build/src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000012d9965a 7. /build/src/Functions/IFunction.cpp:351: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d93b02 8. /build/src/Functions/IFunction.cpp:177: DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d93698 9. /build/src/Functions/IFunction.cpp:343: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d93aad 10. /build/src/Functions/IFunction.cpp:420: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d95059 11. /build/src/Functions/IFunction.cpp:498: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d95c72 12. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3567: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000014034494 13. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3838: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000014019a9e 14. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3980: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000014018e31 15. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:4304: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000014042fa7 16. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5605: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000014013749 17. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000140127f9 18. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000014011fce 19. /build/src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000001406ce8a 20. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000014973b42 21. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000001497268d 22. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000014974d24 23. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001492924b 24. /build/src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88641 25. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 26. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 27. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 28. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 29. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 30. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 31. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 2025.07.28 12:02:40.453792 [ 17203 ] {} TCPHandler: Code: 43. DB::Exception: Argument 'max_width' must not be NaN: In scope SELECT bar(1, 1, 1, nan). (ILLEGAL_TYPE_OF_ARGUMENT), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000000a074fcb 4. /build/src/Functions/bar.cpp:91: DB::(anonymous namespace)::FunctionBar::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000aad93b9 5. /build/src/Functions/IFunction.h:437: DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000a069f2a 6. /build/src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000012d9965a 7. /build/src/Functions/IFunction.cpp:351: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d93b02 8. /build/src/Functions/IFunction.cpp:177: DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d93698 9. /build/src/Functions/IFunction.cpp:343: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d93aad 10. /build/src/Functions/IFunction.cpp:420: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d95059 11. /build/src/Functions/IFunction.cpp:498: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d95c72 12. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3567: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000014034494 13. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3838: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000014019a9e 14. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3980: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000014018e31 15. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:4304: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000014042fa7 16. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5605: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000014013749 17. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000140127f9 18. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000014011fce 19. /build/src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000001406ce8a 20. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000014973b42 21. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000001497268d 22. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000014974d24 23. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001492924b 24. /build/src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88641 25. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 26. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 27. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 28. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 29. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 30. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 31. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 2025.07.28 12:02:40.469717 [ 62053 ] {e9a51ad8-8c88-4711-aa2e-e19642eab254} executeQuery: Code: 33. DB::Exception: Cannot read all data. Bytes read: 100500. Bytes expected: 1073741823.: while executing 'FUNCTION CAST(concat(_CAST('ÿÿÿ?'_String, 'String'_String), randomString(100500_UInt32)) :: 2, 'AggregateFunction(max, String)'_String :: 3) -> CAST(concat(_CAST('ÿÿÿ?'_String, 'String'_String), randomString(100500_UInt32)), 'AggregateFunction(max, String)'_String) AggregateFunction(max, String) : 4'. (CANNOT_READ_ALL_DATA) (version 25.3.6.10636.altinitytest (altinity build)) (from [::1]:55244) (comment: 02477_single_value_data_string_regression.sql) (query 30, line 100) (in query: SELECT '2^30-1', maxMerge(x) from (select CAST(unhex('ffffff3f') || randomString(100500), 'AggregateFunction(max, String)') as x);), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, unsigned long&, String&&) @ 0x000000000ba5db6b 4. /build/src/IO/ReadBuffer.cpp:49: DB::ReadBuffer::readStrict(char*, unsigned long) @ 0x000000000fc66ec7 5. /build/src/AggregateFunctions/SingleValueData.cpp:0: DB::SingleValueDataString::read(DB::ReadBuffer&, DB::ISerialization const&, std::shared_ptr const&, DB::Arena*) @ 0x00000000109fb14d 6. /build/src/DataTypes/Serializations/SerializationAggregateFunction.cpp:109: DB::deserializeFromString(std::shared_ptr const&, DB::IColumn&, String const&, unsigned long) @ 0x0000000013c80fde 7. /build/src/DataTypes/Serializations/SerializationAggregateFunction.cpp:158: DB::SerializationAggregateFunction::deserializeWholeText(DB::IColumn&, DB::ReadBuffer&, DB::FormatSettings const&) const @ 0x0000000013c8123e 8. /build/src/Functions/FunctionsConversion.h:1922: 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&) @ 0x0000000012de920b 9. /build/src/Functions/FunctionsConversion.h:1894: DB::detail::ConvertImplGenericFromString::execute(std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long, std::shared_ptr const&) @ 0x0000000012de7d2d 10. /build/src/Functions/FunctionsConversion.h:3821: COW::immutable_ptr std::__function::__policy_invoker::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)>::__call_impl[abi:se190107] 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) @ 0x0000000012f96541 11. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000012ddcb1b 12. /build/src/Functions/IFunction.cpp:353: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d93b52 13. /build/src/Functions/IFunction.cpp:424: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d94e1b 14. /build/src/Functions/IFunction.cpp:498: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d95c72 15. /build/src/Interpreters/ExpressionActions.cpp:636: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x00000000145176f3 16. /build/src/Processors/Transforms/ExpressionTransform.cpp:25: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x0000000016c0b34c 17. /build/src/Processors/ISimpleTransform.h:33: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000011a9a453 18. /build/src/Processors/ISimpleTransform.cpp:89: DB::ISimpleTransform::work() @ 0x000000001699fca0 19. /build/src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x00000000169bd00f 20. /build/src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x00000000169b2105 21. /build/src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeSingleThread(unsigned long) @ 0x00000000169b23be 22. /build/src/Processors/Executors/PipelineExecutor.cpp:454: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x00000000169b0be7 23. /build/src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x00000000169b03f4 24. /build/src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:se190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169bfeab 25. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc3d92 26. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fcca080 27. ? @ 0x00007fbc6213eac3 28. ? @ 0x00007fbc621d0850 2025.07.28 12:02:40.506814 [ 62053 ] {} TCPHandler: Code: 33. DB::Exception: Cannot read all data. Bytes read: 100500. Bytes expected: 1073741823.: while executing 'FUNCTION CAST(concat(_CAST('ÿÿÿ?'_String, 'String'_String), randomString(100500_UInt32)) :: 2, 'AggregateFunction(max, String)'_String :: 3) -> CAST(concat(_CAST('ÿÿÿ?'_String, 'String'_String), randomString(100500_UInt32)), 'AggregateFunction(max, String)'_String) AggregateFunction(max, String) : 4'. (CANNOT_READ_ALL_DATA), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, unsigned long&, String&&) @ 0x000000000ba5db6b 4. /build/src/IO/ReadBuffer.cpp:49: DB::ReadBuffer::readStrict(char*, unsigned long) @ 0x000000000fc66ec7 5. /build/src/AggregateFunctions/SingleValueData.cpp:0: DB::SingleValueDataString::read(DB::ReadBuffer&, DB::ISerialization const&, std::shared_ptr const&, DB::Arena*) @ 0x00000000109fb14d 6. /build/src/DataTypes/Serializations/SerializationAggregateFunction.cpp:109: DB::deserializeFromString(std::shared_ptr const&, DB::IColumn&, String const&, unsigned long) @ 0x0000000013c80fde 7. /build/src/DataTypes/Serializations/SerializationAggregateFunction.cpp:158: DB::SerializationAggregateFunction::deserializeWholeText(DB::IColumn&, DB::ReadBuffer&, DB::FormatSettings const&) const @ 0x0000000013c8123e 8. /build/src/Functions/FunctionsConversion.h:1922: 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&) @ 0x0000000012de920b 9. /build/src/Functions/FunctionsConversion.h:1894: DB::detail::ConvertImplGenericFromString::execute(std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long, std::shared_ptr const&) @ 0x0000000012de7d2d 10. /build/src/Functions/FunctionsConversion.h:3821: COW::immutable_ptr std::__function::__policy_invoker::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)>::__call_impl[abi:se190107] 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) @ 0x0000000012f96541 11. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000012ddcb1b 12. /build/src/Functions/IFunction.cpp:353: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d93b52 13. /build/src/Functions/IFunction.cpp:424: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d94e1b 14. /build/src/Functions/IFunction.cpp:498: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d95c72 15. /build/src/Interpreters/ExpressionActions.cpp:636: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x00000000145176f3 16. /build/src/Processors/Transforms/ExpressionTransform.cpp:25: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x0000000016c0b34c 17. /build/src/Processors/ISimpleTransform.h:33: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000011a9a453 18. /build/src/Processors/ISimpleTransform.cpp:89: DB::ISimpleTransform::work() @ 0x000000001699fca0 19. /build/src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x00000000169bd00f 20. /build/src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x00000000169b2105 21. /build/src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeSingleThread(unsigned long) @ 0x00000000169b23be 22. /build/src/Processors/Executors/PipelineExecutor.cpp:454: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x00000000169b0be7 23. /build/src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x00000000169b03f4 24. /build/src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:se190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169bfeab 25. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc3d92 26. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fcca080 27. ? @ 0x00007fbc6213eac3 28. ? @ 0x00007fbc621d0850 Job's origin stack trace: 0. /build/src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000000fc33b84 1. /build/src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000000fcc2ea7 2. /build/src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fcc535c 3. /build/src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000000fcc584d 4. /build/src/Common/ThreadPool.h:279: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x00000000169bf193 5. /build/src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x00000000169bf518 6. /build/src/Server/TCPHandler.cpp:1237: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x00000000168f1525 7. /build/src/Server/TCPHandler.cpp:678: DB::TCPHandler::runImpl() @ 0x00000000168e68e5 8. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 9. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 10. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 11. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 12. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 13. ? @ 0x00007fbc6213eac3 14. ? @ 0x00007fbc621d0850 2025.07.28 12:02:41.020414 [ 3965 ] {} test_13.rmt2 (7f9b740d-015c-470e-8cc6-8ba33be0dc63): auto DB::StorageReplicatedMergeTree::processQueueEntry(ReplicatedMergeTreeQueue::SelectedEntryPtr)::(anonymous class)::operator()(LogEntryPtr &) const: Code: 86. DB::HTTPException: Received error from remote server http://146b4357c08d:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Ftest%2F01165%2Ftest_13%2Frmt%2Freplicas%2F1&part=20250728_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.6.10636.altinitytest (altinity build)) '. (RECEIVED_ERROR_FROM_REMOTE_IO_SERVER), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.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 const&, int&&, String const&, unsigned long&&, String const&) @ 0x000000000feda8d9 4. /build/src/IO/HTTPCommon.cpp:104: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x000000000feda6e2 5. /build/src/IO/HTTPCommon.cpp:93: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x000000000feda537 6. /build/src/IO/ReadWriteBufferFromHTTP.cpp:277: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x000000001184a4c4 7. /build/src/IO/ReadWriteBufferFromHTTP.cpp:285: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x000000001184a615 8. /build/src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x000000001184ae59 9. /build/src/IO/ReadWriteBufferFromHTTP.cpp:472: void std::__function::__policy_invoker::__call_impl[abi:se190107]>(std::__function::__policy_storage const*) @ 0x000000001184cedd 10. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001184858b 11. /build/src/IO/ReadWriteBufferFromHTTP.cpp:465: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x000000001184bf0b 12. /build/src/IO/ReadBuffer.h:60: DB::ReadBuffer::next() @ 0x000000000a148c7b 13. /build/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) @ 0x0000000011849fb2 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]>&)>&, 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&) @ 0x0000000011841980 15. /build/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) @ 0x000000001621208e 16. /build/src/Storages/StorageReplicatedMergeTree.cpp:5228: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl[abi:se190107] const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000015f9a5fe 17. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000015ed8bfd 18. /build/src/Storages/StorageReplicatedMergeTree.cpp:2514: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x0000000015ec9aab 19. /build/src/Storages/StorageReplicatedMergeTree.cpp:2349: DB::StorageReplicatedMergeTree::executeLogEntry(DB::ReplicatedMergeTreeLogEntry&) @ 0x0000000015eba91b 20. /build/src/Storages/StorageReplicatedMergeTree.cpp:3876: bool std::__function::__policy_invoker&)>::__call_impl[abi:se190107])::$_1, bool (std::shared_ptr&)>>(std::__function::__policy_storage const*, std::shared_ptr&) @ 0x0000000015f9837e 21. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000165d6fc3 22. /build/src/Storages/StorageReplicatedMergeTree.cpp:3872: DB::StorageReplicatedMergeTree::processQueueEntry(std::shared_ptr) @ 0x0000000015efc18a 23. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001624c1b2 24. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000162f9c70 25. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x00000000162fa55a 26. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc6653 27. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000000fccc4c3 28. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc3d92 29. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fcca080 30. ? @ 0x00007fbc6213eac3 31. ? @ 0x00007fbc621d0850 (version 25.3.6.10636.altinitytest (altinity build)) 2025.07.28 12:02:41.077437 [ 62053 ] {61272527-57c0-4608-86b5-c49dbd19cb08} executeQuery: Code: 117. DB::Exception: Invalid state of the aggregate function argMax: has_value (true) != has_result (false): In scope SELECT 'fuzz1', finalizeAggregation(CAST(unhex('3000000\0303132333435363738393031323334353637383930313233343536373839303132333435363738393031323334353600010000000000000000'), 'AggregateFunction(argMax, String, UInt64)')). (INCORRECT_DATA) (version 25.3.6.10636.altinitytest (altinity build)) (from [::1]:55244) (comment: 02477_single_value_data_string_regression.sql) (query 33, line 106) (in query: SELECT 'fuzz1', finalizeAggregation(CAST(unhex('3000000\0303132333435363738393031323334353637383930313233343536373839303132333435363738393031323334353600010000000000000000'), 'AggregateFunction(argMax, String, UInt64)'));), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, bool&&, bool&&) @ 0x0000000010bd558b 4. /build/src/AggregateFunctions/AggregateFunctionsArgMinArgMax.cpp:239: DB::(anonymous namespace)::AggregateFunctionArgMinMax>, false>::deserialize(char*, DB::ReadBuffer&, std::optional, DB::Arena*) const @ 0x0000000010bba2bd 5. /build/src/DataTypes/Serializations/SerializationAggregateFunction.cpp:109: DB::deserializeFromString(std::shared_ptr const&, DB::IColumn&, String const&, unsigned long) @ 0x0000000013c80fde 6. /build/src/DataTypes/Serializations/SerializationAggregateFunction.cpp:158: DB::SerializationAggregateFunction::deserializeWholeText(DB::IColumn&, DB::ReadBuffer&, DB::FormatSettings const&) const @ 0x0000000013c8123e 7. /build/src/Functions/FunctionsConversion.h:1922: 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&) @ 0x0000000012de920b 8. /build/src/Functions/FunctionsConversion.h:1894: DB::detail::ConvertImplGenericFromString::execute(std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long, std::shared_ptr const&) @ 0x0000000012de7d2d 9. /build/src/Functions/FunctionsConversion.h:3821: COW::immutable_ptr std::__function::__policy_invoker::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)>::__call_impl[abi:se190107] 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) @ 0x0000000012f96541 10. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000012ddcb1b 11. /build/src/Functions/IFunction.h:57: DB::IExecutableFunction::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000a08134a 12. /build/src/Functions/IFunction.cpp:351: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d93b02 13. /build/src/Functions/IFunction.cpp:177: DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d93698 14. /build/src/Functions/IFunction.cpp:343: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d93aad 15. /build/src/Functions/IFunction.cpp:424: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d94e1b 16. /build/src/Functions/IFunction.cpp:498: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d95c72 17. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3567: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000014034494 18. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3838: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000014019a9e 19. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3980: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000014018e31 20. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:2925: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000001402fcbd 21. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3838: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000014019a9e 22. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3980: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000014018e31 23. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:4304: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000014042fa7 24. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5605: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000014013749 25. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000140127f9 26. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000014011fce 27. /build/src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000001406ce8a 28. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000014973b42 29. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000001497268d 30. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000014974d24 31. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001492924b 2025.07.28 12:02:41.082572 [ 62053 ] {} TCPHandler: Code: 117. DB::Exception: Invalid state of the aggregate function argMax: has_value (true) != has_result (false): In scope SELECT 'fuzz1', finalizeAggregation(CAST(unhex('3000000\0303132333435363738393031323334353637383930313233343536373839303132333435363738393031323334353600010000000000000000'), 'AggregateFunction(argMax, String, UInt64)')). (INCORRECT_DATA), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, bool&&, bool&&) @ 0x0000000010bd558b 4. /build/src/AggregateFunctions/AggregateFunctionsArgMinArgMax.cpp:239: DB::(anonymous namespace)::AggregateFunctionArgMinMax>, false>::deserialize(char*, DB::ReadBuffer&, std::optional, DB::Arena*) const @ 0x0000000010bba2bd 5. /build/src/DataTypes/Serializations/SerializationAggregateFunction.cpp:109: DB::deserializeFromString(std::shared_ptr const&, DB::IColumn&, String const&, unsigned long) @ 0x0000000013c80fde 6. /build/src/DataTypes/Serializations/SerializationAggregateFunction.cpp:158: DB::SerializationAggregateFunction::deserializeWholeText(DB::IColumn&, DB::ReadBuffer&, DB::FormatSettings const&) const @ 0x0000000013c8123e 7. /build/src/Functions/FunctionsConversion.h:1922: 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&) @ 0x0000000012de920b 8. /build/src/Functions/FunctionsConversion.h:1894: DB::detail::ConvertImplGenericFromString::execute(std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long, std::shared_ptr const&) @ 0x0000000012de7d2d 9. /build/src/Functions/FunctionsConversion.h:3821: COW::immutable_ptr std::__function::__policy_invoker::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)>::__call_impl[abi:se190107] 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) @ 0x0000000012f96541 10. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000012ddcb1b 11. /build/src/Functions/IFunction.h:57: DB::IExecutableFunction::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000a08134a 12. /build/src/Functions/IFunction.cpp:351: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d93b02 13. /build/src/Functions/IFunction.cpp:177: DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d93698 14. /build/src/Functions/IFunction.cpp:343: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d93aad 15. /build/src/Functions/IFunction.cpp:424: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d94e1b 16. /build/src/Functions/IFunction.cpp:498: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d95c72 17. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3567: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000014034494 18. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3838: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000014019a9e 19. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3980: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000014018e31 20. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:2925: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000001402fcbd 21. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3838: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000014019a9e 22. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3980: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000014018e31 23. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:4304: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000014042fa7 24. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5605: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000014013749 25. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000140127f9 26. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000014011fce 27. /build/src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000001406ce8a 28. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000014973b42 29. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000001497268d 30. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000014974d24 31. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001492924b 2025.07.28 12:02:41.239968 [ 62053 ] {6a9c4ba5-d0ac-4d1d-b196-99db0f246bc0} executeQuery: Code: 117. DB::Exception: Invalid state of the aggregate function argMax: has_value (false) != has_result (true): In scope SELECT 'fuzz3', finalizeAggregation(CAST(unhex(concat('04000000', '30313233', '00', 'ffffffffffffffff')), 'AggregateFunction(argMax, String, UInt64)')) AS x, length(x). (INCORRECT_DATA) (version 25.3.6.10636.altinitytest (altinity build)) (from [::1]:55244) (comment: 02477_single_value_data_string_regression.sql) (query 35, line 108) (in query: SELECT 'fuzz3', finalizeAggregation(CAST(unhex('04000000' || '30313233' || '00' || 'ffffffffffffffff'), 'AggregateFunction(argMax, String, UInt64)')) as x, length(x);), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, bool&&, bool&&) @ 0x0000000010bd558b 4. /build/src/AggregateFunctions/AggregateFunctionsArgMinArgMax.cpp:239: DB::(anonymous namespace)::AggregateFunctionArgMinMax>, false>::deserialize(char*, DB::ReadBuffer&, std::optional, DB::Arena*) const @ 0x0000000010bba2bd 5. /build/src/DataTypes/Serializations/SerializationAggregateFunction.cpp:109: DB::deserializeFromString(std::shared_ptr const&, DB::IColumn&, String const&, unsigned long) @ 0x0000000013c80fde 6. /build/src/DataTypes/Serializations/SerializationAggregateFunction.cpp:158: DB::SerializationAggregateFunction::deserializeWholeText(DB::IColumn&, DB::ReadBuffer&, DB::FormatSettings const&) const @ 0x0000000013c8123e 7. /build/src/Functions/FunctionsConversion.h:1922: 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&) @ 0x0000000012de920b 8. /build/src/Functions/FunctionsConversion.h:1894: DB::detail::ConvertImplGenericFromString::execute(std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long, std::shared_ptr const&) @ 0x0000000012de7d2d 9. /build/src/Functions/FunctionsConversion.h:3821: COW::immutable_ptr std::__function::__policy_invoker::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)>::__call_impl[abi:se190107] 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) @ 0x0000000012f96541 10. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000012ddcb1b 11. /build/src/Functions/IFunction.h:57: DB::IExecutableFunction::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000a08134a 12. /build/src/Functions/IFunction.cpp:351: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d93b02 13. /build/src/Functions/IFunction.cpp:177: DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d93698 14. /build/src/Functions/IFunction.cpp:343: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d93aad 15. /build/src/Functions/IFunction.cpp:424: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d94e1b 16. /build/src/Functions/IFunction.cpp:498: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d95c72 17. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3567: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000014034494 18. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3838: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000014019a9e 19. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3980: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000014018e31 20. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:2925: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000001402fcbd 21. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3838: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000014019a9e 22. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3980: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000014018e31 23. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:4304: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000014042fa7 24. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5605: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000014013749 25. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000140127f9 26. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000014011fce 27. /build/src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000001406ce8a 28. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000014973b42 29. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000001497268d 30. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000014974d24 31. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001492924b 2025.07.28 12:02:41.256509 [ 62053 ] {} TCPHandler: Code: 117. DB::Exception: Invalid state of the aggregate function argMax: has_value (false) != has_result (true): In scope SELECT 'fuzz3', finalizeAggregation(CAST(unhex(concat('04000000', '30313233', '00', 'ffffffffffffffff')), 'AggregateFunction(argMax, String, UInt64)')) AS x, length(x). (INCORRECT_DATA), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, bool&&, bool&&) @ 0x0000000010bd558b 4. /build/src/AggregateFunctions/AggregateFunctionsArgMinArgMax.cpp:239: DB::(anonymous namespace)::AggregateFunctionArgMinMax>, false>::deserialize(char*, DB::ReadBuffer&, std::optional, DB::Arena*) const @ 0x0000000010bba2bd 5. /build/src/DataTypes/Serializations/SerializationAggregateFunction.cpp:109: DB::deserializeFromString(std::shared_ptr const&, DB::IColumn&, String const&, unsigned long) @ 0x0000000013c80fde 6. /build/src/DataTypes/Serializations/SerializationAggregateFunction.cpp:158: DB::SerializationAggregateFunction::deserializeWholeText(DB::IColumn&, DB::ReadBuffer&, DB::FormatSettings const&) const @ 0x0000000013c8123e 7. /build/src/Functions/FunctionsConversion.h:1922: 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&) @ 0x0000000012de920b 8. /build/src/Functions/FunctionsConversion.h:1894: DB::detail::ConvertImplGenericFromString::execute(std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long, std::shared_ptr const&) @ 0x0000000012de7d2d 9. /build/src/Functions/FunctionsConversion.h:3821: COW::immutable_ptr std::__function::__policy_invoker::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)>::__call_impl[abi:se190107] 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) @ 0x0000000012f96541 10. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000012ddcb1b 11. /build/src/Functions/IFunction.h:57: DB::IExecutableFunction::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000a08134a 12. /build/src/Functions/IFunction.cpp:351: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d93b02 13. /build/src/Functions/IFunction.cpp:177: DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d93698 14. /build/src/Functions/IFunction.cpp:343: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d93aad 15. /build/src/Functions/IFunction.cpp:424: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d94e1b 16. /build/src/Functions/IFunction.cpp:498: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d95c72 17. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3567: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000014034494 18. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3838: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000014019a9e 19. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3980: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000014018e31 20. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:2925: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000001402fcbd 21. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3838: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000014019a9e 22. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3980: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000014018e31 23. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:4304: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000014042fa7 24. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5605: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000014013749 25. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000140127f9 26. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000014011fce 27. /build/src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000001406ce8a 28. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000014973b42 29. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000001497268d 30. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000014974d24 31. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001492924b 2025.07.28 12:02:41.383137 [ 62053 ] {b0542945-eadf-4c8f-a0b4-53bb03383e36} executeQuery: Code: 117. DB::Exception: Invalid state of the aggregate function argMax: has_value (false) != has_result (true): In scope SELECT 'fuzz4', finalizeAggregation(CAST(unhex(concat('04000000', '30313233', '00')), 'AggregateFunction(argMax, String, UInt64)')) AS x, length(x). (INCORRECT_DATA) (version 25.3.6.10636.altinitytest (altinity build)) (from [::1]:55244) (comment: 02477_single_value_data_string_regression.sql) (query 36, line 109) (in query: SELECT 'fuzz4', finalizeAggregation(CAST(unhex('04000000' || '30313233' || '00'), 'AggregateFunction(argMax, String, UInt64)')) as x, length(x);), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, bool&&, bool&&) @ 0x0000000010bd558b 4. /build/src/AggregateFunctions/AggregateFunctionsArgMinArgMax.cpp:239: DB::(anonymous namespace)::AggregateFunctionArgMinMax>, false>::deserialize(char*, DB::ReadBuffer&, std::optional, DB::Arena*) const @ 0x0000000010bba2bd 5. /build/src/DataTypes/Serializations/SerializationAggregateFunction.cpp:109: DB::deserializeFromString(std::shared_ptr const&, DB::IColumn&, String const&, unsigned long) @ 0x0000000013c80fde 6. /build/src/DataTypes/Serializations/SerializationAggregateFunction.cpp:158: DB::SerializationAggregateFunction::deserializeWholeText(DB::IColumn&, DB::ReadBuffer&, DB::FormatSettings const&) const @ 0x0000000013c8123e 7. /build/src/Functions/FunctionsConversion.h:1922: 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&) @ 0x0000000012de920b 8. /build/src/Functions/FunctionsConversion.h:1894: DB::detail::ConvertImplGenericFromString::execute(std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long, std::shared_ptr const&) @ 0x0000000012de7d2d 9. /build/src/Functions/FunctionsConversion.h:3821: COW::immutable_ptr std::__function::__policy_invoker::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)>::__call_impl[abi:se190107] 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) @ 0x0000000012f96541 10. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000012ddcb1b 11. /build/src/Functions/IFunction.h:57: DB::IExecutableFunction::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000a08134a 12. /build/src/Functions/IFunction.cpp:351: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d93b02 13. /build/src/Functions/IFunction.cpp:177: DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d93698 14. /build/src/Functions/IFunction.cpp:343: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d93aad 15. /build/src/Functions/IFunction.cpp:424: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d94e1b 16. /build/src/Functions/IFunction.cpp:498: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d95c72 17. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3567: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000014034494 18. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3838: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000014019a9e 19. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3980: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000014018e31 20. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:2925: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000001402fcbd 21. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3838: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000014019a9e 22. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3980: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000014018e31 23. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:4304: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000014042fa7 24. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5605: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000014013749 25. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000140127f9 26. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000014011fce 27. /build/src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000001406ce8a 28. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000014973b42 29. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000001497268d 30. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000014974d24 31. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001492924b 2025.07.28 12:02:41.409130 [ 62053 ] {} TCPHandler: Code: 117. DB::Exception: Invalid state of the aggregate function argMax: has_value (false) != has_result (true): In scope SELECT 'fuzz4', finalizeAggregation(CAST(unhex(concat('04000000', '30313233', '00')), 'AggregateFunction(argMax, String, UInt64)')) AS x, length(x). (INCORRECT_DATA), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, bool&&, bool&&) @ 0x0000000010bd558b 4. /build/src/AggregateFunctions/AggregateFunctionsArgMinArgMax.cpp:239: DB::(anonymous namespace)::AggregateFunctionArgMinMax>, false>::deserialize(char*, DB::ReadBuffer&, std::optional, DB::Arena*) const @ 0x0000000010bba2bd 5. /build/src/DataTypes/Serializations/SerializationAggregateFunction.cpp:109: DB::deserializeFromString(std::shared_ptr const&, DB::IColumn&, String const&, unsigned long) @ 0x0000000013c80fde 6. /build/src/DataTypes/Serializations/SerializationAggregateFunction.cpp:158: DB::SerializationAggregateFunction::deserializeWholeText(DB::IColumn&, DB::ReadBuffer&, DB::FormatSettings const&) const @ 0x0000000013c8123e 7. /build/src/Functions/FunctionsConversion.h:1922: 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&) @ 0x0000000012de920b 8. /build/src/Functions/FunctionsConversion.h:1894: DB::detail::ConvertImplGenericFromString::execute(std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long, std::shared_ptr const&) @ 0x0000000012de7d2d 9. /build/src/Functions/FunctionsConversion.h:3821: COW::immutable_ptr std::__function::__policy_invoker::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)>::__call_impl[abi:se190107] 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) @ 0x0000000012f96541 10. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000012ddcb1b 11. /build/src/Functions/IFunction.h:57: DB::IExecutableFunction::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000a08134a 12. /build/src/Functions/IFunction.cpp:351: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d93b02 13. /build/src/Functions/IFunction.cpp:177: DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d93698 14. /build/src/Functions/IFunction.cpp:343: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d93aad 15. /build/src/Functions/IFunction.cpp:424: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d94e1b 16. /build/src/Functions/IFunction.cpp:498: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d95c72 17. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3567: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000014034494 18. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3838: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000014019a9e 19. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3980: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000014018e31 20. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:2925: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000001402fcbd 21. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3838: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000014019a9e 22. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3980: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000014018e31 23. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:4304: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000014042fa7 24. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5605: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000014013749 25. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000140127f9 26. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000014011fce 27. /build/src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000001406ce8a 28. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000014973b42 29. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000001497268d 30. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000014974d24 31. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001492924b 2025.07.28 12:02:41.620189 [ 62053 ] {b7873c6b-dace-44b2-90e3-eb190d04b9ff} executeQuery: Code: 117. DB::Exception: Invalid state of the aggregate function argMax: has_value (false) != has_result (true): In scope SELECT 'fuzz5', finalizeAggregation(CAST(unhex('0100000000000000000FFFFFFFF0'), 'AggregateFunction(argMax, UInt64, String)')). (INCORRECT_DATA) (version 25.3.6.10636.altinitytest (altinity build)) (from [::1]:55244) (comment: 02477_single_value_data_string_regression.sql) (query 37, line 110) (in query: SELECT 'fuzz5', finalizeAggregation(CAST(unhex('0100000000000000000FFFFFFFF0'), 'AggregateFunction(argMax, UInt64, String)'));), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, bool&&, bool&&) @ 0x0000000010bd558b 4. /build/src/AggregateFunctions/AggregateFunctionsArgMinArgMax.cpp:239: DB::(anonymous namespace)::AggregateFunctionArgMinMax, false>::deserialize(char*, DB::ReadBuffer&, std::optional, DB::Arena*) const @ 0x0000000010bd13c0 5. /build/src/DataTypes/Serializations/SerializationAggregateFunction.cpp:109: DB::deserializeFromString(std::shared_ptr const&, DB::IColumn&, String const&, unsigned long) @ 0x0000000013c80fde 6. /build/src/DataTypes/Serializations/SerializationAggregateFunction.cpp:158: DB::SerializationAggregateFunction::deserializeWholeText(DB::IColumn&, DB::ReadBuffer&, DB::FormatSettings const&) const @ 0x0000000013c8123e 7. /build/src/Functions/FunctionsConversion.h:1922: 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&) @ 0x0000000012de920b 8. /build/src/Functions/FunctionsConversion.h:1894: DB::detail::ConvertImplGenericFromString::execute(std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long, std::shared_ptr const&) @ 0x0000000012de7d2d 9. /build/src/Functions/FunctionsConversion.h:3821: COW::immutable_ptr std::__function::__policy_invoker::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)>::__call_impl[abi:se190107] 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) @ 0x0000000012f96541 10. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000012ddcb1b 11. /build/src/Functions/IFunction.h:57: DB::IExecutableFunction::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000a08134a 12. /build/src/Functions/IFunction.cpp:351: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d93b02 13. /build/src/Functions/IFunction.cpp:177: DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d93698 14. /build/src/Functions/IFunction.cpp:343: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d93aad 15. /build/src/Functions/IFunction.cpp:424: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d94e1b 16. /build/src/Functions/IFunction.cpp:498: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d95c72 17. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3567: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000014034494 18. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3838: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000014019a9e 19. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3980: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000014018e31 20. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:2925: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000001402fcbd 21. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3838: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000014019a9e 22. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3980: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000014018e31 23. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:4304: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000014042fa7 24. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5605: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000014013749 25. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000140127f9 26. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000014011fce 27. /build/src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000001406ce8a 28. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000014973b42 29. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000001497268d 30. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000014974d24 31. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001492924b 2025.07.28 12:02:41.629935 [ 62053 ] {} TCPHandler: Code: 117. DB::Exception: Invalid state of the aggregate function argMax: has_value (false) != has_result (true): In scope SELECT 'fuzz5', finalizeAggregation(CAST(unhex('0100000000000000000FFFFFFFF0'), 'AggregateFunction(argMax, UInt64, String)')). (INCORRECT_DATA), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, bool&&, bool&&) @ 0x0000000010bd558b 4. /build/src/AggregateFunctions/AggregateFunctionsArgMinArgMax.cpp:239: DB::(anonymous namespace)::AggregateFunctionArgMinMax, false>::deserialize(char*, DB::ReadBuffer&, std::optional, DB::Arena*) const @ 0x0000000010bd13c0 5. /build/src/DataTypes/Serializations/SerializationAggregateFunction.cpp:109: DB::deserializeFromString(std::shared_ptr const&, DB::IColumn&, String const&, unsigned long) @ 0x0000000013c80fde 6. /build/src/DataTypes/Serializations/SerializationAggregateFunction.cpp:158: DB::SerializationAggregateFunction::deserializeWholeText(DB::IColumn&, DB::ReadBuffer&, DB::FormatSettings const&) const @ 0x0000000013c8123e 7. /build/src/Functions/FunctionsConversion.h:1922: 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&) @ 0x0000000012de920b 8. /build/src/Functions/FunctionsConversion.h:1894: DB::detail::ConvertImplGenericFromString::execute(std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long, std::shared_ptr const&) @ 0x0000000012de7d2d 9. /build/src/Functions/FunctionsConversion.h:3821: COW::immutable_ptr std::__function::__policy_invoker::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)>::__call_impl[abi:se190107] 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) @ 0x0000000012f96541 10. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000012ddcb1b 11. /build/src/Functions/IFunction.h:57: DB::IExecutableFunction::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000a08134a 12. /build/src/Functions/IFunction.cpp:351: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d93b02 13. /build/src/Functions/IFunction.cpp:177: DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d93698 14. /build/src/Functions/IFunction.cpp:343: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d93aad 15. /build/src/Functions/IFunction.cpp:424: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d94e1b 16. /build/src/Functions/IFunction.cpp:498: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d95c72 17. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3567: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000014034494 18. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3838: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000014019a9e 19. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3980: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000014018e31 20. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:2925: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000001402fcbd 21. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3838: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000014019a9e 22. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3980: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000014018e31 23. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:4304: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000014042fa7 24. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5605: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000014013749 25. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000140127f9 26. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000014011fce 27. /build/src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000001406ce8a 28. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000014973b42 29. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000001497268d 30. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000014974d24 31. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001492924b 2025.07.28 12:02:41.802639 [ 3974 ] {} test_13.rmt2 (7f9b740d-015c-470e-8cc6-8ba33be0dc63): auto DB::StorageReplicatedMergeTree::processQueueEntry(ReplicatedMergeTreeQueue::SelectedEntryPtr)::(anonymous class)::operator()(LogEntryPtr &) const: Code: 86. DB::HTTPException: Received error from remote server http://146b4357c08d:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Ftest%2F01165%2Ftest_13%2Frmt%2Freplicas%2F1&part=20250728_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.6.10636.altinitytest (altinity build)) '. (RECEIVED_ERROR_FROM_REMOTE_IO_SERVER), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.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 const&, int&&, String const&, unsigned long&&, String const&) @ 0x000000000feda8d9 4. /build/src/IO/HTTPCommon.cpp:104: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x000000000feda6e2 5. /build/src/IO/HTTPCommon.cpp:93: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x000000000feda537 6. /build/src/IO/ReadWriteBufferFromHTTP.cpp:277: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x000000001184a4c4 7. /build/src/IO/ReadWriteBufferFromHTTP.cpp:285: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x000000001184a615 8. /build/src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x000000001184ae59 9. /build/src/IO/ReadWriteBufferFromHTTP.cpp:472: void std::__function::__policy_invoker::__call_impl[abi:se190107]>(std::__function::__policy_storage const*) @ 0x000000001184cedd 10. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001184858b 11. /build/src/IO/ReadWriteBufferFromHTTP.cpp:465: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x000000001184bf0b 12. /build/src/IO/ReadBuffer.h:60: DB::ReadBuffer::next() @ 0x000000000a148c7b 13. /build/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) @ 0x0000000011849fb2 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]>&)>&, 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&) @ 0x0000000011841980 15. /build/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) @ 0x000000001621208e 16. /build/src/Storages/StorageReplicatedMergeTree.cpp:5228: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl[abi:se190107] const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000015f9a5fe 17. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000015ed8bfd 18. /build/src/Storages/StorageReplicatedMergeTree.cpp:2514: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x0000000015ec9aab 19. /build/src/Storages/StorageReplicatedMergeTree.cpp:2349: DB::StorageReplicatedMergeTree::executeLogEntry(DB::ReplicatedMergeTreeLogEntry&) @ 0x0000000015eba91b 20. /build/src/Storages/StorageReplicatedMergeTree.cpp:3876: bool std::__function::__policy_invoker&)>::__call_impl[abi:se190107])::$_1, bool (std::shared_ptr&)>>(std::__function::__policy_storage const*, std::shared_ptr&) @ 0x0000000015f9837e 21. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000165d6fc3 22. /build/src/Storages/StorageReplicatedMergeTree.cpp:3872: DB::StorageReplicatedMergeTree::processQueueEntry(std::shared_ptr) @ 0x0000000015efc18a 23. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001624c1b2 24. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000162f9c70 25. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x00000000162fa55a 26. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc6653 27. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000000fccc4c3 28. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc3d92 29. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fcca080 30. ? @ 0x00007fbc6213eac3 31. ? @ 0x00007fbc621d0850 (version 25.3.6.10636.altinitytest (altinity build)) 2025.07.28 12:02:41.828042 [ 11826 ] {dba776c1-eeae-4e2f-bcba-f7021f515ace} executeQueryWithParallelReplicas: Setting 'use_hedged_requests' explicitly with enabled 'enable_parallel_replicas' has no effect. Hedged connections are not used for parallel reading from replicas 2025.07.28 12:02:41.931017 [ 62058 ] {2e1bc852-dd85-4523-9c2e-87e9a3836df7} executeQuery: Code: 115. DB::Exception: Unknown setting 'custom_e': In scope SELECT getSetting('custom_e') AS v, toTypeName(v). (UNKNOWN_SETTING) (version 25.3.6.10636.altinitytest (altinity build)) (from [::1]:56536) (comment: 01418_custom_settings.sql) (query 23, line 26) (in query: SELECT getSetting('custom_e') as v, toTypeName(v);), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x000000000a06b56b 4. /build/src/Core/BaseSettings.cpp:53: DB::BaseSettingsHelpers::throwSettingNotFound(std::basic_string_view>) @ 0x0000000013968a63 5. /build/src/Core/BaseSettings.h:641: DB::BaseSettings::get(std::basic_string_view>) const @ 0x0000000013b062db 6. /build/src/Core/Settings.cpp:6464: DB::Settings::get(std::basic_string_view>) const @ 0x0000000013a567ec 7. /build/src/Functions/getSetting.cpp:72: DB::(anonymous namespace)::FunctionGetSetting<(DB::(anonymous namespace)::ErrorHandlingMode)0>::getValue(std::vector> const&) const @ 0x000000000ba675cb 8. /build/src/Functions/getSetting.cpp:46: DB::(anonymous namespace)::FunctionGetSetting<(DB::(anonymous namespace)::ErrorHandlingMode)0>::getReturnTypeImpl(std::vector> const&) const @ 0x000000000ba674ba 9. /build/src/Functions/IFunction.cpp:645: DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x0000000012d96b0c 10. /build/src/Functions/IFunction.cpp:577: DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x0000000012d9669c 11. /build/src/Functions/IFunction.cpp:606: DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x0000000012d96edc 12. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3544: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000014033cc9 13. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3838: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000014019a9e 14. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3980: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000014018e31 15. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:4304: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000014042fa7 16. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5605: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000014013749 17. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000140127f9 18. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000014011fce 19. /build/src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000001406ce8a 20. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000014973b42 21. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000001497268d 22. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000014974d24 23. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001492924b 24. /build/src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88641 25. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 26. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 27. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 28. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 29. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 30. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 31. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 2025.07.28 12:02:41.942641 [ 62058 ] {} TCPHandler: Code: 115. DB::Exception: Unknown setting 'custom_e': In scope SELECT getSetting('custom_e') AS v, toTypeName(v). (UNKNOWN_SETTING), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x000000000a06b56b 4. /build/src/Core/BaseSettings.cpp:53: DB::BaseSettingsHelpers::throwSettingNotFound(std::basic_string_view>) @ 0x0000000013968a63 5. /build/src/Core/BaseSettings.h:641: DB::BaseSettings::get(std::basic_string_view>) const @ 0x0000000013b062db 6. /build/src/Core/Settings.cpp:6464: DB::Settings::get(std::basic_string_view>) const @ 0x0000000013a567ec 7. /build/src/Functions/getSetting.cpp:72: DB::(anonymous namespace)::FunctionGetSetting<(DB::(anonymous namespace)::ErrorHandlingMode)0>::getValue(std::vector> const&) const @ 0x000000000ba675cb 8. /build/src/Functions/getSetting.cpp:46: DB::(anonymous namespace)::FunctionGetSetting<(DB::(anonymous namespace)::ErrorHandlingMode)0>::getReturnTypeImpl(std::vector> const&) const @ 0x000000000ba674ba 9. /build/src/Functions/IFunction.cpp:645: DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x0000000012d96b0c 10. /build/src/Functions/IFunction.cpp:577: DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x0000000012d9669c 11. /build/src/Functions/IFunction.cpp:606: DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x0000000012d96edc 12. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3544: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000014033cc9 13. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3838: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000014019a9e 14. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3980: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000014018e31 15. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:4304: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000014042fa7 16. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5605: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000014013749 17. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000140127f9 18. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000014011fce 19. /build/src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000001406ce8a 20. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000014973b42 21. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000001497268d 22. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000014974d24 23. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001492924b 24. /build/src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88641 25. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 26. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 27. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 28. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 29. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 30. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 31. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 2025.07.28 12:02:42.042454 [ 3969 ] {} test_13.rmt2 (7f9b740d-015c-470e-8cc6-8ba33be0dc63): auto DB::StorageReplicatedMergeTree::processQueueEntry(ReplicatedMergeTreeQueue::SelectedEntryPtr)::(anonymous class)::operator()(LogEntryPtr &) const: Code: 86. DB::HTTPException: Received error from remote server http://146b4357c08d:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Ftest%2F01165%2Ftest_13%2Frmt%2Freplicas%2F1&part=20250728_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.6.10636.altinitytest (altinity build)) '. (RECEIVED_ERROR_FROM_REMOTE_IO_SERVER), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.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 const&, int&&, String const&, unsigned long&&, String const&) @ 0x000000000feda8d9 4. /build/src/IO/HTTPCommon.cpp:104: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x000000000feda6e2 5. /build/src/IO/HTTPCommon.cpp:93: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x000000000feda537 6. /build/src/IO/ReadWriteBufferFromHTTP.cpp:277: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x000000001184a4c4 7. /build/src/IO/ReadWriteBufferFromHTTP.cpp:285: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x000000001184a615 8. /build/src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x000000001184ae59 9. /build/src/IO/ReadWriteBufferFromHTTP.cpp:472: void std::__function::__policy_invoker::__call_impl[abi:se190107]>(std::__function::__policy_storage const*) @ 0x000000001184cedd 10. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001184858b 11. /build/src/IO/ReadWriteBufferFromHTTP.cpp:465: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x000000001184bf0b 12. /build/src/IO/ReadBuffer.h:60: DB::ReadBuffer::next() @ 0x000000000a148c7b 13. /build/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) @ 0x0000000011849fb2 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]>&)>&, 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&) @ 0x0000000011841980 15. /build/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) @ 0x000000001621208e 16. /build/src/Storages/StorageReplicatedMergeTree.cpp:5228: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl[abi:se190107] const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000015f9a5fe 17. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000015ed8bfd 18. /build/src/Storages/StorageReplicatedMergeTree.cpp:2514: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x0000000015ec9aab 19. /build/src/Storages/StorageReplicatedMergeTree.cpp:2349: DB::StorageReplicatedMergeTree::executeLogEntry(DB::ReplicatedMergeTreeLogEntry&) @ 0x0000000015eba91b 20. /build/src/Storages/StorageReplicatedMergeTree.cpp:3876: bool std::__function::__policy_invoker&)>::__call_impl[abi:se190107])::$_1, bool (std::shared_ptr&)>>(std::__function::__policy_storage const*, std::shared_ptr&) @ 0x0000000015f9837e 21. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000165d6fc3 22. /build/src/Storages/StorageReplicatedMergeTree.cpp:3872: DB::StorageReplicatedMergeTree::processQueueEntry(std::shared_ptr) @ 0x0000000015efc18a 23. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001624c1b2 24. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000162f9c70 25. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x00000000162fa55a 26. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc6653 27. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000000fccc4c3 28. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc3d92 29. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fcca080 30. ? @ 0x00007fbc6213eac3 31. ? @ 0x00007fbc621d0850 (version 25.3.6.10636.altinitytest (altinity build)) 2025.07.28 12:02:42.163915 [ 62058 ] {afd4b2d6-a06e-43b9-89d7-9b8c724e5295} executeQuery: Code: 115. DB::Exception: Setting invalid_custom is neither a builtin setting nor started with the prefix 'SQL_' or 'custom_' registered for user-defined settings. (UNKNOWN_SETTING) (version 25.3.6.10636.altinitytest (altinity build)) (from [::1]:56536) (comment: 01418_custom_settings.sql) (query 27, line 31) (in query: SET invalid_custom = 8;), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000a06a8eb 4. /build/src/Access/AccessControl.cpp:134: DB::AccessControl::CustomSettingsPrefixes::checkSettingNameIsAllowed(std::basic_string_view>) const @ 0x0000000013728ca1 5. /build/src/Access/SettingsConstraints.cpp:279: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000013858f56 6. /build/src/Access/SettingsConstraints.cpp:194: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges const&, DB::SettingSource) const @ 0x00000000138591b3 7. /build/src/Interpreters/Context.cpp:2722: DB::Context::checkSettingsConstraints(DB::SettingsChanges const&, DB::SettingSource) @ 0x0000000014436509 8. /build/src/Interpreters/InterpreterSetQuery.cpp:28: DB::InterpreterSetQuery::execute() @ 0x00000000149e240a 9. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88dc9 10. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 11. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 12. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 13. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 14. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 16. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 17. ? @ 0x00007fbc6213eac3 18. ? @ 0x00007fbc621d0850 2025.07.28 12:02:42.184840 [ 62058 ] {} TCPHandler: Code: 115. DB::Exception: Setting invalid_custom is neither a builtin setting nor started with the prefix 'SQL_' or 'custom_' registered for user-defined settings. (UNKNOWN_SETTING), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000a06a8eb 4. /build/src/Access/AccessControl.cpp:134: DB::AccessControl::CustomSettingsPrefixes::checkSettingNameIsAllowed(std::basic_string_view>) const @ 0x0000000013728ca1 5. /build/src/Access/SettingsConstraints.cpp:279: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000013858f56 6. /build/src/Access/SettingsConstraints.cpp:194: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges const&, DB::SettingSource) const @ 0x00000000138591b3 7. /build/src/Interpreters/Context.cpp:2722: DB::Context::checkSettingsConstraints(DB::SettingsChanges const&, DB::SettingSource) @ 0x0000000014436509 8. /build/src/Interpreters/InterpreterSetQuery.cpp:28: DB::InterpreterSetQuery::execute() @ 0x00000000149e240a 9. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88dc9 10. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 11. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 12. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 13. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 14. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 16. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 17. ? @ 0x00007fbc6213eac3 18. ? @ 0x00007fbc621d0850 2025.07.28 12:02:42.716931 [ 3967 ] {} test_13.rmt2 (7f9b740d-015c-470e-8cc6-8ba33be0dc63): auto DB::StorageReplicatedMergeTree::processQueueEntry(ReplicatedMergeTreeQueue::SelectedEntryPtr)::(anonymous class)::operator()(LogEntryPtr &) const: Code: 86. DB::HTTPException: Received error from remote server http://146b4357c08d:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Ftest%2F01165%2Ftest_13%2Frmt%2Freplicas%2F1&part=20250728_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.6.10636.altinitytest (altinity build)) '. (RECEIVED_ERROR_FROM_REMOTE_IO_SERVER), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.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 const&, int&&, String const&, unsigned long&&, String const&) @ 0x000000000feda8d9 4. /build/src/IO/HTTPCommon.cpp:104: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x000000000feda6e2 5. /build/src/IO/HTTPCommon.cpp:93: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x000000000feda537 6. /build/src/IO/ReadWriteBufferFromHTTP.cpp:277: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x000000001184a4c4 7. /build/src/IO/ReadWriteBufferFromHTTP.cpp:285: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x000000001184a615 8. /build/src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x000000001184ae59 9. /build/src/IO/ReadWriteBufferFromHTTP.cpp:472: void std::__function::__policy_invoker::__call_impl[abi:se190107]>(std::__function::__policy_storage const*) @ 0x000000001184cedd 10. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001184858b 11. /build/src/IO/ReadWriteBufferFromHTTP.cpp:465: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x000000001184bf0b 12. /build/src/IO/ReadBuffer.h:60: DB::ReadBuffer::next() @ 0x000000000a148c7b 13. /build/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) @ 0x0000000011849fb2 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]>&)>&, 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&) @ 0x0000000011841980 15. /build/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) @ 0x000000001621208e 16. /build/src/Storages/StorageReplicatedMergeTree.cpp:5228: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl[abi:se190107] const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000015f9a5fe 17. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000015ed8bfd 18. /build/src/Storages/StorageReplicatedMergeTree.cpp:2514: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x0000000015ec9aab 19. /build/src/Storages/StorageReplicatedMergeTree.cpp:2349: DB::StorageReplicatedMergeTree::executeLogEntry(DB::ReplicatedMergeTreeLogEntry&) @ 0x0000000015eba91b 20. /build/src/Storages/StorageReplicatedMergeTree.cpp:3876: bool std::__function::__policy_invoker&)>::__call_impl[abi:se190107])::$_1, bool (std::shared_ptr&)>>(std::__function::__policy_storage const*, std::shared_ptr&) @ 0x0000000015f9837e 21. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000165d6fc3 22. /build/src/Storages/StorageReplicatedMergeTree.cpp:3872: DB::StorageReplicatedMergeTree::processQueueEntry(std::shared_ptr) @ 0x0000000015efc18a 23. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001624c1b2 24. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000162f9c70 25. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x00000000162fa55a 26. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc6653 27. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000000fccc4c3 28. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc3d92 29. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fcca080 30. ? @ 0x00007fbc6213eac3 31. ? @ 0x00007fbc621d0850 (version 25.3.6.10636.altinitytest (altinity build)) 2025.07.28 12:02:42.980190 [ 62058 ] {9340a084-6ab1-4ca8-b973-64ba108b55a4} executeQuery: Code: 115. DB::Exception: Unknown setting 'custom_f': In scope SELECT getSetting('custom_f') AS v, toTypeName(v). (UNKNOWN_SETTING) (version 25.3.6.10636.altinitytest (altinity build)) (from [::1]:56536) (comment: 01418_custom_settings.sql) (query 35, line 41) (in query: SELECT getSetting('custom_f') as v, toTypeName(v);), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x000000000a06b56b 4. /build/src/Core/BaseSettings.cpp:53: DB::BaseSettingsHelpers::throwSettingNotFound(std::basic_string_view>) @ 0x0000000013968a63 5. /build/src/Core/BaseSettings.h:641: DB::BaseSettings::get(std::basic_string_view>) const @ 0x0000000013b062db 6. /build/src/Core/Settings.cpp:6464: DB::Settings::get(std::basic_string_view>) const @ 0x0000000013a567ec 7. /build/src/Functions/getSetting.cpp:72: DB::(anonymous namespace)::FunctionGetSetting<(DB::(anonymous namespace)::ErrorHandlingMode)0>::getValue(std::vector> const&) const @ 0x000000000ba675cb 8. /build/src/Functions/getSetting.cpp:46: DB::(anonymous namespace)::FunctionGetSetting<(DB::(anonymous namespace)::ErrorHandlingMode)0>::getReturnTypeImpl(std::vector> const&) const @ 0x000000000ba674ba 9. /build/src/Functions/IFunction.cpp:645: DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x0000000012d96b0c 10. /build/src/Functions/IFunction.cpp:577: DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x0000000012d9669c 11. /build/src/Functions/IFunction.cpp:606: DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x0000000012d96edc 12. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3544: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000014033cc9 13. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3838: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000014019a9e 14. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3980: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000014018e31 15. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:4304: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000014042fa7 16. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5605: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000014013749 17. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000140127f9 18. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000014011fce 19. /build/src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000001406ce8a 20. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000014973b42 21. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000001497268d 22. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000014974d24 23. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001492924b 24. /build/src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88641 25. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 26. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 27. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 28. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 29. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 30. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 31. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 2025.07.28 12:02:42.998952 [ 62058 ] {} TCPHandler: Code: 115. DB::Exception: Unknown setting 'custom_f': In scope SELECT getSetting('custom_f') AS v, toTypeName(v). (UNKNOWN_SETTING), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x000000000a06b56b 4. /build/src/Core/BaseSettings.cpp:53: DB::BaseSettingsHelpers::throwSettingNotFound(std::basic_string_view>) @ 0x0000000013968a63 5. /build/src/Core/BaseSettings.h:641: DB::BaseSettings::get(std::basic_string_view>) const @ 0x0000000013b062db 6. /build/src/Core/Settings.cpp:6464: DB::Settings::get(std::basic_string_view>) const @ 0x0000000013a567ec 7. /build/src/Functions/getSetting.cpp:72: DB::(anonymous namespace)::FunctionGetSetting<(DB::(anonymous namespace)::ErrorHandlingMode)0>::getValue(std::vector> const&) const @ 0x000000000ba675cb 8. /build/src/Functions/getSetting.cpp:46: DB::(anonymous namespace)::FunctionGetSetting<(DB::(anonymous namespace)::ErrorHandlingMode)0>::getReturnTypeImpl(std::vector> const&) const @ 0x000000000ba674ba 9. /build/src/Functions/IFunction.cpp:645: DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x0000000012d96b0c 10. /build/src/Functions/IFunction.cpp:577: DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x0000000012d9669c 11. /build/src/Functions/IFunction.cpp:606: DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x0000000012d96edc 12. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3544: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000014033cc9 13. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3838: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000014019a9e 14. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3980: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000014018e31 15. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:4304: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000014042fa7 16. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5605: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000014013749 17. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000140127f9 18. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000014011fce 19. /build/src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000001406ce8a 20. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000014973b42 21. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000001497268d 22. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000014974d24 23. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001492924b 24. /build/src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88641 25. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 26. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 27. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 28. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 29. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 30. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 31. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 2025.07.28 12:02:43.539919 [ 3971 ] {} test_13.rmt2 (7f9b740d-015c-470e-8cc6-8ba33be0dc63): auto DB::StorageReplicatedMergeTree::processQueueEntry(ReplicatedMergeTreeQueue::SelectedEntryPtr)::(anonymous class)::operator()(LogEntryPtr &) const: Code: 86. DB::HTTPException: Received error from remote server http://146b4357c08d:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Ftest%2F01165%2Ftest_13%2Frmt%2Freplicas%2F1&part=20250728_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.6.10636.altinitytest (altinity build)) '. (RECEIVED_ERROR_FROM_REMOTE_IO_SERVER), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.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 const&, int&&, String const&, unsigned long&&, String const&) @ 0x000000000feda8d9 4. /build/src/IO/HTTPCommon.cpp:104: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x000000000feda6e2 5. /build/src/IO/HTTPCommon.cpp:93: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x000000000feda537 6. /build/src/IO/ReadWriteBufferFromHTTP.cpp:277: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x000000001184a4c4 7. /build/src/IO/ReadWriteBufferFromHTTP.cpp:285: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x000000001184a615 8. /build/src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x000000001184ae59 9. /build/src/IO/ReadWriteBufferFromHTTP.cpp:472: void std::__function::__policy_invoker::__call_impl[abi:se190107]>(std::__function::__policy_storage const*) @ 0x000000001184cedd 10. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001184858b 11. /build/src/IO/ReadWriteBufferFromHTTP.cpp:465: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x000000001184bf0b 12. /build/src/IO/ReadBuffer.h:60: DB::ReadBuffer::next() @ 0x000000000a148c7b 13. /build/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) @ 0x0000000011849fb2 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]>&)>&, 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&) @ 0x0000000011841980 15. /build/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) @ 0x000000001621208e 16. /build/src/Storages/StorageReplicatedMergeTree.cpp:5228: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl[abi:se190107] const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000015f9a5fe 17. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000015ed8bfd 18. /build/src/Storages/StorageReplicatedMergeTree.cpp:2514: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x0000000015ec9aab 19. /build/src/Storages/StorageReplicatedMergeTree.cpp:2349: DB::StorageReplicatedMergeTree::executeLogEntry(DB::ReplicatedMergeTreeLogEntry&) @ 0x0000000015eba91b 20. /build/src/Storages/StorageReplicatedMergeTree.cpp:3876: bool std::__function::__policy_invoker&)>::__call_impl[abi:se190107])::$_1, bool (std::shared_ptr&)>>(std::__function::__policy_storage const*, std::shared_ptr&) @ 0x0000000015f9837e 21. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000165d6fc3 22. /build/src/Storages/StorageReplicatedMergeTree.cpp:3872: DB::StorageReplicatedMergeTree::processQueueEntry(std::shared_ptr) @ 0x0000000015efc18a 23. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001624c1b2 24. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000162f9c70 25. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x00000000162fa55a 26. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc6653 27. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000000fccc4c3 28. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc3d92 29. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fcca080 30. ? @ 0x00007fbc6213eac3 31. ? @ 0x00007fbc621d0850 (version 25.3.6.10636.altinitytest (altinity build)) 2025.07.28 12:02:44.398580 [ 3972 ] {} test_13.rmt2 (7f9b740d-015c-470e-8cc6-8ba33be0dc63): auto DB::StorageReplicatedMergeTree::processQueueEntry(ReplicatedMergeTreeQueue::SelectedEntryPtr)::(anonymous class)::operator()(LogEntryPtr &) const: Code: 86. DB::HTTPException: Received error from remote server http://146b4357c08d:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Ftest%2F01165%2Ftest_13%2Frmt%2Freplicas%2F1&part=20250728_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.6.10636.altinitytest (altinity build)) '. (RECEIVED_ERROR_FROM_REMOTE_IO_SERVER), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.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 const&, int&&, String const&, unsigned long&&, String const&) @ 0x000000000feda8d9 4. /build/src/IO/HTTPCommon.cpp:104: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x000000000feda6e2 5. /build/src/IO/HTTPCommon.cpp:93: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x000000000feda537 6. /build/src/IO/ReadWriteBufferFromHTTP.cpp:277: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x000000001184a4c4 7. /build/src/IO/ReadWriteBufferFromHTTP.cpp:285: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x000000001184a615 8. /build/src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x000000001184ae59 9. /build/src/IO/ReadWriteBufferFromHTTP.cpp:472: void std::__function::__policy_invoker::__call_impl[abi:se190107]>(std::__function::__policy_storage const*) @ 0x000000001184cedd 10. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001184858b 11. /build/src/IO/ReadWriteBufferFromHTTP.cpp:465: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x000000001184bf0b 12. /build/src/IO/ReadBuffer.h:60: DB::ReadBuffer::next() @ 0x000000000a148c7b 13. /build/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) @ 0x0000000011849fb2 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]>&)>&, 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&) @ 0x0000000011841980 15. /build/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) @ 0x000000001621208e 16. /build/src/Storages/StorageReplicatedMergeTree.cpp:5228: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl[abi:se190107] const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000015f9a5fe 17. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000015ed8bfd 18. /build/src/Storages/StorageReplicatedMergeTree.cpp:2514: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x0000000015ec9aab 19. /build/src/Storages/StorageReplicatedMergeTree.cpp:2349: DB::StorageReplicatedMergeTree::executeLogEntry(DB::ReplicatedMergeTreeLogEntry&) @ 0x0000000015eba91b 20. /build/src/Storages/StorageReplicatedMergeTree.cpp:3876: bool std::__function::__policy_invoker&)>::__call_impl[abi:se190107])::$_1, bool (std::shared_ptr&)>>(std::__function::__policy_storage const*, std::shared_ptr&) @ 0x0000000015f9837e 21. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000165d6fc3 22. /build/src/Storages/StorageReplicatedMergeTree.cpp:3872: DB::StorageReplicatedMergeTree::processQueueEntry(std::shared_ptr) @ 0x0000000015efc18a 23. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001624c1b2 24. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000162f9c70 25. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x00000000162fa55a 26. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc6653 27. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000000fccc4c3 28. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc3d92 29. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fcca080 30. ? @ 0x00007fbc6213eac3 31. ? @ 0x00007fbc621d0850 (version 25.3.6.10636.altinitytest (altinity build)) 2025.07.28 12:02:44.505030 [ 17243 ] {a1e1be4f-849d-4271-a8b9-f580e22357d9} executeQuery: Code: 190. DB::Exception: Arrays passed to arrayMap must have equal size. Argument 3 has size 2 which differs with the size of another argument, 3. (SIZES_OF_ARRAYS_DONT_MATCH) (version 25.3.6.10636.altinitytest (altinity build)) (from [::1]:49504) (comment: 03001_bad_error_message_higher_order_functions.sh) (query 1, line 1) (in query: SELECT arrayMap((x,y) -> x + y, [1,2,3], [1,2])), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, String&&, unsigned long&&, unsigned long const&, unsigned long const&) @ 0x000000000ea4ff8b 4. /build/src/Functions/array/FunctionArrayMapped.h:335: DB::FunctionArrayMapped::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000ea548a7 5. /build/src/Functions/IFunction.h:437: DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000a069f2a 6. /build/src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000012d9965a 7. /build/src/Functions/IFunction.cpp:351: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d93b02 8. /build/src/Functions/IFunction.cpp:177: DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d93698 9. /build/src/Functions/IFunction.cpp:343: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d93aad 10. /build/src/Functions/IFunction.cpp:420: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d95059 11. /build/src/Functions/IFunction.cpp:498: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d95c72 12. /build/src/Interpreters/ActionsDAG.cpp:413: DB::ActionsDAG::addFunctionImpl(std::shared_ptr const&, std::vector>, std::vector>, String, std::shared_ptr, bool) @ 0x0000000013f9c819 13. /build/src/Interpreters/ActionsDAG.cpp:346: DB::ActionsDAG::addFunction(DB::FunctionNode const&, std::vector>, String) @ 0x0000000013f9cf68 14. /build/src/Planner/PlannerActionsVisitor.cpp:536: DB::(anonymous namespace)::PlannerActionsVisitorImpl::visitImpl(std::shared_ptr) @ 0x0000000013fdd3a7 15. /build/src/Planner/PlannerActionsVisitor.cpp:645: DB::PlannerActionsVisitor::visit(DB::ActionsDAG&, std::shared_ptr) @ 0x0000000013fd6889 16. /build/src/Planner/Utils.cpp:237: DB::buildActionsDAGFromExpressionNode(std::shared_ptr const&, std::vector> const&, std::shared_ptr const&) @ 0x0000000013fe73b2 17. /build/src/Planner/PlannerExpressionAnalysis.cpp:380: DB::buildExpressionAnalysisResult(std::shared_ptr const&, std::vector> const&, std::shared_ptr const&, DB::PlannerQueryProcessingInfo const&) @ 0x00000000149cceac 18. /build/src/Planner/Planner.cpp:1578: DB::Planner::buildPlanForQueryNode() @ 0x000000001497acb3 19. /build/src/Planner/Planner.cpp:1308: DB::Planner::buildQueryPlanIfNeeded() @ 0x000000001497685c 20. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:255: DB::InterpreterSelectQueryAnalyzer::getQueryPlan() @ 0x000000001497476d 21. /build/src/Interpreters/executeQuery.cpp:1405: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88806 22. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 23. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 24. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 25. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 26. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 27. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 28. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 29. ? @ 0x00007fbc6213eac3 30. ? @ 0x00007fbc621d0850 2025.07.28 12:02:44.524812 [ 17243 ] {} TCPHandler: Code: 190. DB::Exception: Arrays passed to arrayMap must have equal size. Argument 3 has size 2 which differs with the size of another argument, 3. (SIZES_OF_ARRAYS_DONT_MATCH), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, String&&, unsigned long&&, unsigned long const&, unsigned long const&) @ 0x000000000ea4ff8b 4. /build/src/Functions/array/FunctionArrayMapped.h:335: DB::FunctionArrayMapped::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000ea548a7 5. /build/src/Functions/IFunction.h:437: DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000a069f2a 6. /build/src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000012d9965a 7. /build/src/Functions/IFunction.cpp:351: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d93b02 8. /build/src/Functions/IFunction.cpp:177: DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d93698 9. /build/src/Functions/IFunction.cpp:343: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d93aad 10. /build/src/Functions/IFunction.cpp:420: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d95059 11. /build/src/Functions/IFunction.cpp:498: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d95c72 12. /build/src/Interpreters/ActionsDAG.cpp:413: DB::ActionsDAG::addFunctionImpl(std::shared_ptr const&, std::vector>, std::vector>, String, std::shared_ptr, bool) @ 0x0000000013f9c819 13. /build/src/Interpreters/ActionsDAG.cpp:346: DB::ActionsDAG::addFunction(DB::FunctionNode const&, std::vector>, String) @ 0x0000000013f9cf68 14. /build/src/Planner/PlannerActionsVisitor.cpp:536: DB::(anonymous namespace)::PlannerActionsVisitorImpl::visitImpl(std::shared_ptr) @ 0x0000000013fdd3a7 15. /build/src/Planner/PlannerActionsVisitor.cpp:645: DB::PlannerActionsVisitor::visit(DB::ActionsDAG&, std::shared_ptr) @ 0x0000000013fd6889 16. /build/src/Planner/Utils.cpp:237: DB::buildActionsDAGFromExpressionNode(std::shared_ptr const&, std::vector> const&, std::shared_ptr const&) @ 0x0000000013fe73b2 17. /build/src/Planner/PlannerExpressionAnalysis.cpp:380: DB::buildExpressionAnalysisResult(std::shared_ptr const&, std::vector> const&, std::shared_ptr const&, DB::PlannerQueryProcessingInfo const&) @ 0x00000000149cceac 18. /build/src/Planner/Planner.cpp:1578: DB::Planner::buildPlanForQueryNode() @ 0x000000001497acb3 19. /build/src/Planner/Planner.cpp:1308: DB::Planner::buildQueryPlanIfNeeded() @ 0x000000001497685c 20. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:255: DB::InterpreterSelectQueryAnalyzer::getQueryPlan() @ 0x000000001497476d 21. /build/src/Interpreters/executeQuery.cpp:1405: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88806 22. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 23. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 24. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 25. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 26. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 27. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 28. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 29. ? @ 0x00007fbc6213eac3 30. ? @ 0x00007fbc621d0850 2025.07.28 12:02:45.172641 [ 3974 ] {} test_13.rmt2 (7f9b740d-015c-470e-8cc6-8ba33be0dc63): auto DB::StorageReplicatedMergeTree::processQueueEntry(ReplicatedMergeTreeQueue::SelectedEntryPtr)::(anonymous class)::operator()(LogEntryPtr &) const: Code: 86. DB::HTTPException: Received error from remote server http://146b4357c08d:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Ftest%2F01165%2Ftest_13%2Frmt%2Freplicas%2F1&part=20250728_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.6.10636.altinitytest (altinity build)) '. (RECEIVED_ERROR_FROM_REMOTE_IO_SERVER), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.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 const&, int&&, String const&, unsigned long&&, String const&) @ 0x000000000feda8d9 4. /build/src/IO/HTTPCommon.cpp:104: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x000000000feda6e2 5. /build/src/IO/HTTPCommon.cpp:93: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x000000000feda537 6. /build/src/IO/ReadWriteBufferFromHTTP.cpp:277: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x000000001184a4c4 7. /build/src/IO/ReadWriteBufferFromHTTP.cpp:285: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x000000001184a615 8. /build/src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x000000001184ae59 9. /build/src/IO/ReadWriteBufferFromHTTP.cpp:472: void std::__function::__policy_invoker::__call_impl[abi:se190107]>(std::__function::__policy_storage const*) @ 0x000000001184cedd 10. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001184858b 11. /build/src/IO/ReadWriteBufferFromHTTP.cpp:465: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x000000001184bf0b 12. /build/src/IO/ReadBuffer.h:60: DB::ReadBuffer::next() @ 0x000000000a148c7b 13. /build/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) @ 0x0000000011849fb2 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]>&)>&, 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&) @ 0x0000000011841980 15. /build/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) @ 0x000000001621208e 16. /build/src/Storages/StorageReplicatedMergeTree.cpp:5228: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl[abi:se190107] const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000015f9a5fe 17. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000015ed8bfd 18. /build/src/Storages/StorageReplicatedMergeTree.cpp:2514: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x0000000015ec9aab 19. /build/src/Storages/StorageReplicatedMergeTree.cpp:2349: DB::StorageReplicatedMergeTree::executeLogEntry(DB::ReplicatedMergeTreeLogEntry&) @ 0x0000000015eba91b 20. /build/src/Storages/StorageReplicatedMergeTree.cpp:3876: bool std::__function::__policy_invoker&)>::__call_impl[abi:se190107])::$_1, bool (std::shared_ptr&)>>(std::__function::__policy_storage const*, std::shared_ptr&) @ 0x0000000015f9837e 21. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000165d6fc3 22. /build/src/Storages/StorageReplicatedMergeTree.cpp:3872: DB::StorageReplicatedMergeTree::processQueueEntry(std::shared_ptr) @ 0x0000000015efc18a 23. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001624c1b2 24. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000162f9c70 25. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x00000000162fa55a 26. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc6653 27. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000000fccc4c3 28. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc3d92 29. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fcca080 30. ? @ 0x00007fbc6213eac3 31. ? @ 0x00007fbc621d0850 (version 25.3.6.10636.altinitytest (altinity build)) 2025.07.28 12:02:45.313037 [ 17203 ] {ba0443ae-1a93-4268-a279-626c2a14b2a7} executeQuery: Code: 57. DB::Exception: Table test_15.t1 already exists. (TABLE_ALREADY_EXISTS) (version 25.3.6.10636.altinitytest (altinity build)) (from [::1]:49550) (comment: 03084_analyzer_join_column_alias.sql) (query 2, line 3) (in query: CREATE TABLE t1 ENGINE = MergeTree ORDER BY tuple() SETTINGS index_granularity = 42947, 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 = 286867919, compact_parts_max_bytes_to_buffer = 164393865, compact_parts_max_granules_to_buffer = 256, compact_parts_merge_max_bytes_to_prefetch_part = 14445857, merge_max_block_size = 3568, old_parts_lifetime = 480., prefer_fetch_merged_part_size_threshold = 10737418240, vertical_merge_algorithm_min_rows_to_activate = 1, vertical_merge_algorithm_min_columns_to_activate = 32, min_merge_bytes_to_use_direct_io = 8639857199, index_granularity_bytes = 10029939, 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 = true, enable_block_offset_column = true, cache_populated_by_fetch = false, marks_compress_block_size = 25434, primary_key_compress_block_size = 84223, use_primary_key_cache = false, prewarm_primary_key_cache = false, prewarm_mark_cache = false AS SELECT 1 AS user_id, 2 AS level), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000a06a8eb 4. /build/src/Interpreters/InterpreterCreateQuery.cpp:1824: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x0000000014901d53 5. /build/src/Interpreters/InterpreterCreateQuery.cpp:1743: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000148f9aa9 6. /build/src/Interpreters/InterpreterCreateQuery.cpp:2352: DB::InterpreterCreateQuery::execute() @ 0x0000000014905a41 7. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88dc9 8. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 9. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 10. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 11. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 12. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 13. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 14. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 15. ? @ 0x00007fbc6213eac3 16. ? @ 0x00007fbc621d0850 2025.07.28 12:02:45.338131 [ 17203 ] {} TCPHandler: Code: 57. DB::Exception: Table test_15.t1 already exists. (TABLE_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000a06a8eb 4. /build/src/Interpreters/InterpreterCreateQuery.cpp:1824: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x0000000014901d53 5. /build/src/Interpreters/InterpreterCreateQuery.cpp:1743: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000148f9aa9 6. /build/src/Interpreters/InterpreterCreateQuery.cpp:2352: DB::InterpreterCreateQuery::execute() @ 0x0000000014905a41 7. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88dc9 8. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 9. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 10. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 11. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 12. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 13. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 14. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 15. ? @ 0x00007fbc6213eac3 16. ? @ 0x00007fbc621d0850 2025.07.28 12:02:45.509386 [ 3976 ] {} test_13.rmt2 (7f9b740d-015c-470e-8cc6-8ba33be0dc63): auto DB::StorageReplicatedMergeTree::processQueueEntry(ReplicatedMergeTreeQueue::SelectedEntryPtr)::(anonymous class)::operator()(LogEntryPtr &) const: Code: 86. DB::HTTPException: Received error from remote server http://146b4357c08d:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Ftest%2F01165%2Ftest_13%2Frmt%2Freplicas%2F1&part=20250728_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.6.10636.altinitytest (altinity build)) '. (RECEIVED_ERROR_FROM_REMOTE_IO_SERVER), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.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 const&, int&&, String const&, unsigned long&&, String const&) @ 0x000000000feda8d9 4. /build/src/IO/HTTPCommon.cpp:104: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x000000000feda6e2 5. /build/src/IO/HTTPCommon.cpp:93: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x000000000feda537 6. /build/src/IO/ReadWriteBufferFromHTTP.cpp:277: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x000000001184a4c4 7. /build/src/IO/ReadWriteBufferFromHTTP.cpp:285: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x000000001184a615 8. /build/src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x000000001184ae59 9. /build/src/IO/ReadWriteBufferFromHTTP.cpp:472: void std::__function::__policy_invoker::__call_impl[abi:se190107]>(std::__function::__policy_storage const*) @ 0x000000001184cedd 10. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001184858b 11. /build/src/IO/ReadWriteBufferFromHTTP.cpp:465: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x000000001184bf0b 12. /build/src/IO/ReadBuffer.h:60: DB::ReadBuffer::next() @ 0x000000000a148c7b 13. /build/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) @ 0x0000000011849fb2 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]>&)>&, 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&) @ 0x0000000011841980 15. /build/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) @ 0x000000001621208e 16. /build/src/Storages/StorageReplicatedMergeTree.cpp:5228: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl[abi:se190107] const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000015f9a5fe 17. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000015ed8bfd 18. /build/src/Storages/StorageReplicatedMergeTree.cpp:2514: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x0000000015ec9aab 19. /build/src/Storages/StorageReplicatedMergeTree.cpp:2349: DB::StorageReplicatedMergeTree::executeLogEntry(DB::ReplicatedMergeTreeLogEntry&) @ 0x0000000015eba91b 20. /build/src/Storages/StorageReplicatedMergeTree.cpp:3876: bool std::__function::__policy_invoker&)>::__call_impl[abi:se190107])::$_1, bool (std::shared_ptr&)>>(std::__function::__policy_storage const*, std::shared_ptr&) @ 0x0000000015f9837e 21. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000165d6fc3 22. /build/src/Storages/StorageReplicatedMergeTree.cpp:3872: DB::StorageReplicatedMergeTree::processQueueEntry(std::shared_ptr) @ 0x0000000015efc18a 23. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001624c1b2 24. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000162f9c70 25. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x00000000162fa55a 26. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc6653 27. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000000fccc4c3 28. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc3d92 29. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fcca080 30. ? @ 0x00007fbc6213eac3 31. ? @ 0x00007fbc621d0850 (version 25.3.6.10636.altinitytest (altinity build)) 2025.07.28 12:02:45.866738 [ 62056 ] {0294256c-fb16-430f-a32c-c6237cfb479d} Context: Server has databases (for example `test_z5479pyc`) 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.07.28 12:02:45.974802 [ 3965 ] {} test_13.rmt2 (7f9b740d-015c-470e-8cc6-8ba33be0dc63): auto DB::StorageReplicatedMergeTree::processQueueEntry(ReplicatedMergeTreeQueue::SelectedEntryPtr)::(anonymous class)::operator()(LogEntryPtr &) const: Code: 86. DB::HTTPException: Received error from remote server http://146b4357c08d:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Ftest%2F01165%2Ftest_13%2Frmt%2Freplicas%2F1&part=20250728_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.6.10636.altinitytest (altinity build)) '. (RECEIVED_ERROR_FROM_REMOTE_IO_SERVER), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.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 const&, int&&, String const&, unsigned long&&, String const&) @ 0x000000000feda8d9 4. /build/src/IO/HTTPCommon.cpp:104: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x000000000feda6e2 5. /build/src/IO/HTTPCommon.cpp:93: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x000000000feda537 6. /build/src/IO/ReadWriteBufferFromHTTP.cpp:277: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x000000001184a4c4 7. /build/src/IO/ReadWriteBufferFromHTTP.cpp:285: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x000000001184a615 8. /build/src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x000000001184ae59 9. /build/src/IO/ReadWriteBufferFromHTTP.cpp:472: void std::__function::__policy_invoker::__call_impl[abi:se190107]>(std::__function::__policy_storage const*) @ 0x000000001184cedd 10. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001184858b 11. /build/src/IO/ReadWriteBufferFromHTTP.cpp:465: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x000000001184bf0b 12. /build/src/IO/ReadBuffer.h:60: DB::ReadBuffer::next() @ 0x000000000a148c7b 13. /build/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) @ 0x0000000011849fb2 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]>&)>&, 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&) @ 0x0000000011841980 15. /build/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) @ 0x000000001621208e 16. /build/src/Storages/StorageReplicatedMergeTree.cpp:5228: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl[abi:se190107] const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000015f9a5fe 17. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000015ed8bfd 18. /build/src/Storages/StorageReplicatedMergeTree.cpp:2514: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x0000000015ec9aab 19. /build/src/Storages/StorageReplicatedMergeTree.cpp:2349: DB::StorageReplicatedMergeTree::executeLogEntry(DB::ReplicatedMergeTreeLogEntry&) @ 0x0000000015eba91b 20. /build/src/Storages/StorageReplicatedMergeTree.cpp:3876: bool std::__function::__policy_invoker&)>::__call_impl[abi:se190107])::$_1, bool (std::shared_ptr&)>>(std::__function::__policy_storage const*, std::shared_ptr&) @ 0x0000000015f9837e 21. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000165d6fc3 22. /build/src/Storages/StorageReplicatedMergeTree.cpp:3872: DB::StorageReplicatedMergeTree::processQueueEntry(std::shared_ptr) @ 0x0000000015efc18a 23. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001624c1b2 24. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000162f9c70 25. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x00000000162fa55a 26. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc6653 27. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000000fccc4c3 28. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc3d92 29. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fcca080 30. ? @ 0x00007fbc6213eac3 31. ? @ 0x00007fbc621d0850 (version 25.3.6.10636.altinitytest (altinity build)) 2025.07.28 12:02:46.231066 [ 62056 ] {403d5f66-00a2-4944-bb22-29bac440daf0} executeQuery: Code: 48. DB::Exception: Table test_z5479pyc.my_table belongs to database with Ordinary engine. This engine is deprecated and is not supported in transactions. (NOT_IMPLEMENTED) (version 25.3.6.10636.altinitytest (altinity build)) (from [::1]:49578) (comment: 01053_drop_database_mat_view.sql) (query 6, line 9) (in query: CREATE TABLE test_z5479pyc.my_table ENGINE = MergeTree(day, day, 8192) AS SELECT today() AS day, 'mystring' AS str), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x000000000a06b56b 4. /build/src/Interpreters/MergeTreeTransaction.cpp:25: DB::checkNotOrdinaryDatabase(std::shared_ptr const&) @ 0x0000000014a1d22a 5. /build/src/Interpreters/MergeTreeTransaction.cpp:138: DB::MergeTreeTransaction::addNewPart(std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000014a1c759 6. /build/src/Interpreters/MergeTreeTransaction.cpp:117: DB::MergeTreeTransaction::addNewPartAndRemoveCovered(std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, DB::MergeTreeTransaction*) @ 0x0000000014a1ce4d 7. /build/src/Storages/MergeTree/MergeTreeData.cpp:7218: DB::MergeTreeData::Transaction::commit(DB::DataPartsLock*) @ 0x000000001636c6c6 8. /build/src/Storages/MergeTree/MergeTreeSink.cpp:248: DB::MergeTreeSink::finishDelayedChunk() @ 0x000000001666c577 9. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000016c0abf5 10. /build/src/Processors/Transforms/ExceptionKeepingTransform.cpp:187: DB::ExceptionKeepingTransform::work() @ 0x0000000016c0a7bc 11. /build/src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x00000000169bd00f 12. /build/src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x00000000169b2105 13. /build/src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeSingleThread(unsigned long) @ 0x00000000169b23be 14. /build/src/Processors/Executors/PipelineExecutor.cpp:416: void std::__function::__policy_invoker::__call_impl[abi:se190107]>(std::__function::__policy_storage const*) @ 0x00000000169b2e3f 15. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc6653 16. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000000fccc4c3 17. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc3d92 18. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fcca080 19. ? @ 0x00007fbc6213eac3 20. ? @ 0x00007fbc621d0850 2025.07.28 12:02:46.243800 [ 62056 ] {} TCPHandler: Code: 48. DB::Exception: Table test_z5479pyc.my_table belongs to database with Ordinary engine. This engine is deprecated and is not supported in transactions. (NOT_IMPLEMENTED), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x000000000a06b56b 4. /build/src/Interpreters/MergeTreeTransaction.cpp:25: DB::checkNotOrdinaryDatabase(std::shared_ptr const&) @ 0x0000000014a1d22a 5. /build/src/Interpreters/MergeTreeTransaction.cpp:138: DB::MergeTreeTransaction::addNewPart(std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000014a1c759 6. /build/src/Interpreters/MergeTreeTransaction.cpp:117: DB::MergeTreeTransaction::addNewPartAndRemoveCovered(std::shared_ptr const&, std::shared_ptr const&, std::vector, std::allocator>> const&, DB::MergeTreeTransaction*) @ 0x0000000014a1ce4d 7. /build/src/Storages/MergeTree/MergeTreeData.cpp:7218: DB::MergeTreeData::Transaction::commit(DB::DataPartsLock*) @ 0x000000001636c6c6 8. /build/src/Storages/MergeTree/MergeTreeSink.cpp:248: DB::MergeTreeSink::finishDelayedChunk() @ 0x000000001666c577 9. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000016c0abf5 10. /build/src/Processors/Transforms/ExceptionKeepingTransform.cpp:187: DB::ExceptionKeepingTransform::work() @ 0x0000000016c0a7bc 11. /build/src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x00000000169bd00f 12. /build/src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x00000000169b2105 13. /build/src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeSingleThread(unsigned long) @ 0x00000000169b23be 14. /build/src/Processors/Executors/PipelineExecutor.cpp:416: void std::__function::__policy_invoker::__call_impl[abi:se190107]>(std::__function::__policy_storage const*) @ 0x00000000169b2e3f 15. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc6653 16. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000000fccc4c3 17. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc3d92 18. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fcca080 19. ? @ 0x00007fbc6213eac3 20. ? @ 0x00007fbc621d0850 Job's origin stack trace: 0. /build/src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000000fc33b84 1. /build/src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000000fcc2ea7 2. /build/src/Common/ThreadPool.cpp:401: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fcc7f1c 3. /build/src/Common/ThreadPool.cpp:494: ThreadPoolImpl>::scheduleOrThrowOnError(std::function, Priority) @ 0x000000000fcc7a0e 4. /build/src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::spawnThreadsImpl() @ 0x00000000169b2c0c 5. /build/src/Processors/Executors/PipelineExecutor.cpp:394: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x00000000169b0ba7 6. /build/src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x00000000169b03f4 7. /build/src/Processors/Executors/CompletedPipelineExecutor.cpp:42: void std::__function::__policy_invoker::__call_impl[abi:se190107]::ThreadFromGlobalPoolImpl(DB::CompletedPipelineExecutor::execute()::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169af7e1 8. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc3d92 9. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fcca080 10. ? @ 0x00007fbc6213eac3 11. ? @ 0x00007fbc621d0850 Job's origin stack trace: 0. /build/src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000000fc33b84 1. /build/src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000000fcc2ea7 2. /build/src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fcc535c 3. /build/src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000000fcc584d 4. /build/src/Common/ThreadPool.h:279: DB::CompletedPipelineExecutor::execute() @ 0x00000000169af267 5. /build/src/Server/TCPHandler.cpp:707: DB::TCPHandler::runImpl() @ 0x00000000168e6b2e 6. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 7. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 8. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 9. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 10. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 11. ? @ 0x00007fbc6213eac3 12. ? @ 0x00007fbc621d0850 2025.07.28 12:02:46.396648 [ 62056 ] {d9c92b1a-a050-4fcb-80cc-8c23689f7031} executeQuery: Code: 219. DB::Exception: New table appeared in database being dropped or detached. Try again. (DATABASE_NOT_EMPTY) (version 25.3.6.10636.altinitytest (altinity build)) (from [::1]:41924) (comment: 01053_drop_database_mat_view.sql) (in query: DROP DATABASE IF EXISTS test_z5479pyc SYNC ), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000000a074fcb 4. /build/src/Interpreters/DatabaseCatalog.cpp:608: DB::DatabaseCatalog::detachDatabase(std::shared_ptr, String const&, bool, bool) @ 0x00000000144f41b9 5. /build/src/Interpreters/InterpreterDropQuery.cpp:482: DB::InterpreterDropQuery::executeToDatabaseImpl(DB::ASTDropQuery const&, std::shared_ptr&, std::vector, DB::UUIDTag>, std::allocator, DB::UUIDTag>>>&) @ 0x00000000149179be 6. /build/src/Interpreters/InterpreterDropQuery.cpp:363: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x0000000014913988 7. /build/src/Interpreters/InterpreterDropQuery.cpp:99: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000014913142 8. /build/src/Interpreters/InterpreterDropQuery.cpp:72: DB::InterpreterDropQuery::execute() @ 0x0000000014912b65 9. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88dc9 10. /build/src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x0000000014c8ca7b 11. /build/src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000001686da12 12. /build/src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x0000000016870807 13. /build/src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x0000000016907e99 14. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 15. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 16. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 17. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 18. ? @ 0x00007fbc6213eac3 19. ? @ 0x00007fbc621d0850 2025.07.28 12:02:46.400706 [ 62056 ] {d9c92b1a-a050-4fcb-80cc-8c23689f7031} 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. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000000a074fcb 4. /build/src/Interpreters/DatabaseCatalog.cpp:608: DB::DatabaseCatalog::detachDatabase(std::shared_ptr, String const&, bool, bool) @ 0x00000000144f41b9 5. /build/src/Interpreters/InterpreterDropQuery.cpp:482: DB::InterpreterDropQuery::executeToDatabaseImpl(DB::ASTDropQuery const&, std::shared_ptr&, std::vector, DB::UUIDTag>, std::allocator, DB::UUIDTag>>>&) @ 0x00000000149179be 6. /build/src/Interpreters/InterpreterDropQuery.cpp:363: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x0000000014913988 7. /build/src/Interpreters/InterpreterDropQuery.cpp:99: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000014913142 8. /build/src/Interpreters/InterpreterDropQuery.cpp:72: DB::InterpreterDropQuery::execute() @ 0x0000000014912b65 9. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88dc9 10. /build/src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x0000000014c8ca7b 11. /build/src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000001686da12 12. /build/src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x0000000016870807 13. /build/src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x0000000016907e99 14. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 15. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 16. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 17. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 18. ? @ 0x00007fbc6213eac3 19. ? @ 0x00007fbc621d0850 (version 25.3.6.10636.altinitytest (altinity build)) 2025.07.28 12:02:52.255674 [ 3961 ] {} test_13.rmt2 (7f9b740d-015c-470e-8cc6-8ba33be0dc63): auto DB::StorageReplicatedMergeTree::processQueueEntry(ReplicatedMergeTreeQueue::SelectedEntryPtr)::(anonymous class)::operator()(LogEntryPtr &) const: Code: 86. DB::HTTPException: Received error from remote server http://146b4357c08d:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Ftest%2F01165%2Ftest_13%2Frmt%2Freplicas%2F1&part=20250728_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.6.10636.altinitytest (altinity build)) '. (RECEIVED_ERROR_FROM_REMOTE_IO_SERVER), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.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 const&, int&&, String const&, unsigned long&&, String const&) @ 0x000000000feda8d9 4. /build/src/IO/HTTPCommon.cpp:104: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x000000000feda6e2 5. /build/src/IO/HTTPCommon.cpp:93: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x000000000feda537 6. /build/src/IO/ReadWriteBufferFromHTTP.cpp:277: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x000000001184a4c4 7. /build/src/IO/ReadWriteBufferFromHTTP.cpp:285: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x000000001184a615 8. /build/src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x000000001184ae59 9. /build/src/IO/ReadWriteBufferFromHTTP.cpp:472: void std::__function::__policy_invoker::__call_impl[abi:se190107]>(std::__function::__policy_storage const*) @ 0x000000001184cedd 10. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001184858b 11. /build/src/IO/ReadWriteBufferFromHTTP.cpp:465: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x000000001184bf0b 12. /build/src/IO/ReadBuffer.h:60: DB::ReadBuffer::next() @ 0x000000000a148c7b 13. /build/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) @ 0x0000000011849fb2 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]>&)>&, 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&) @ 0x0000000011841980 15. /build/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) @ 0x000000001621208e 16. /build/src/Storages/StorageReplicatedMergeTree.cpp:5228: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl[abi:se190107] const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000015f9a5fe 17. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000015ed8bfd 18. /build/src/Storages/StorageReplicatedMergeTree.cpp:2514: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x0000000015ec9aab 19. /build/src/Storages/StorageReplicatedMergeTree.cpp:2349: DB::StorageReplicatedMergeTree::executeLogEntry(DB::ReplicatedMergeTreeLogEntry&) @ 0x0000000015eba91b 20. /build/src/Storages/StorageReplicatedMergeTree.cpp:3876: bool std::__function::__policy_invoker&)>::__call_impl[abi:se190107])::$_1, bool (std::shared_ptr&)>>(std::__function::__policy_storage const*, std::shared_ptr&) @ 0x0000000015f9837e 21. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000165d6fc3 22. /build/src/Storages/StorageReplicatedMergeTree.cpp:3872: DB::StorageReplicatedMergeTree::processQueueEntry(std::shared_ptr) @ 0x0000000015efc18a 23. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001624c1b2 24. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000162f9c70 25. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x00000000162fa55a 26. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc6653 27. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000000fccc4c3 28. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc3d92 29. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fcca080 30. ? @ 0x00007fbc6213eac3 31. ? @ 0x00007fbc621d0850 (version 25.3.6.10636.altinitytest (altinity build)) 2025.07.28 12:02:52.379468 [ 5747 ] {c441ae77-309c-4ae7-acd2-f1cf865a35fa} executeQuery: Code: 159. DB::Exception: Timeout exceeded: elapsed 63105.156186 ms, maximum: 60000 ms: While executing MergeTreeSelect(pool: ReadPoolInOrder, algorithm: InOrder). (TIMEOUT_EXCEEDED) (version 25.3.6.10636.altinitytest (altinity build)) (from [::1]:39016) (comment: 03038_nested_dynamic_merges_wide_horizontal.sql) (query 33, line 43) (in query: select count(), dynamicType(d) || ':' || dynamicType(d.`Tuple(a Dynamic(max_types=2))`.a) as type, isDynamicElementInSharedData(d.`Tuple(a Dynamic(max_types=2))`.a) as flag from test group by type, flag order by count(), type;), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, double&&, long&&) @ 0x0000000013bb358b 4. /build/src/QueryPipeline/ExecutionSpeedLimits.cpp:113: DB::ExecutionSpeedLimits::checkTimeLimit(unsigned long const&, DB::OverflowMode) const @ 0x0000000013bb28cc 5. /build/src/QueryPipeline/ReadProgressCallback.cpp:50: DB::ReadProgressCallback::onProgress(unsigned long, unsigned long, std::list> const&) @ 0x0000000013bb1c3d 6. /build/src/Processors/Executors/ExecutionThreadContext.cpp:68: DB::ExecutionThreadContext::executeTask() @ 0x00000000169bd08f 7. /build/src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x00000000169b2105 8. /build/src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeSingleThread(unsigned long) @ 0x00000000169b23be 9. /build/src/Processors/Executors/PipelineExecutor.cpp:416: void std::__function::__policy_invoker::__call_impl[abi:se190107]>(std::__function::__policy_storage const*) @ 0x00000000169b2e3f 10. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc6653 11. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000000fccc4c3 12. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc3d92 13. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fcca080 14. ? @ 0x00007fbc6213eac3 15. ? @ 0x00007fbc621d0850 2025.07.28 12:02:52.460480 [ 17252 ] {81c8e5aa-5bf4-43a6-900d-80e6ab01cec2} executeQuery: Code: 43. DB::Exception: Illegal types of arguments: Map(String, UInt8), UInt8 for function arrayElement. (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.6.10636.altinitytest (altinity build)) (from [::1]:49666) (comment: 02407_array_element_from_map_wrong_type.sql) (query 1, line 1) (in query: select m[0], materialize(map('key', 42)) as m;), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&) @ 0x000000000a10182b 4. /build/src/Functions/array/arrayElement.cpp:1959: DB::(anonymous namespace)::FunctionArrayElement<(DB::(anonymous namespace)::ArrayElementExceptionMode)0>::executeMap(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000f2baa16 5. /build/src/Functions/array/arrayElement.cpp:2026: DB::(anonymous namespace)::FunctionArrayElement<(DB::(anonymous namespace)::ArrayElementExceptionMode)0>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000f2b6ea5 6. /build/src/Functions/IFunction.h:437: DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000a069f2a 7. /build/src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000012d9965a 8. /build/src/Functions/IFunction.cpp:351: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d93b02 9. /build/src/Functions/IFunction.cpp:420: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d95059 10. /build/src/Functions/IFunction.cpp:498: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d95c72 11. /build/src/Interpreters/ActionsDAG.cpp:812: DB::ActionsDAG::evaluatePartialResult(std::unordered_map, std::equal_to, std::allocator>>&, std::vector> const&, unsigned long, bool) @ 0x0000000013fa38cc 12. /build/src/Interpreters/ActionsDAG.cpp:892: DB::ActionsDAG::updateHeader(DB::Block const&) const @ 0x0000000013fa29a8 13. /build/src/Processors/Transforms/ExpressionTransform.cpp:10: DB::ExpressionTransform::transformHeader(DB::Block const&, DB::ActionsDAG const&) @ 0x0000000016c0afd2 14. /build/src/Processors/QueryPlan/ExpressionStep.cpp:38: DB::ExpressionStep::ExpressionStep(DB::Block const&, DB::ActionsDAG) @ 0x0000000016db8ad1 15. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107](DB::Block const&, DB::ActionsDAG&&) @ 0x00000000131ee01a 16. /build/src/Planner/Planner.cpp:392: DB::(anonymous namespace)::addExpressionStep(DB::QueryPlan&, std::shared_ptr&, String const&, std::unordered_set, std::hash>, std::equal_to>, std::allocator>>&) @ 0x000000001498191d 17. /build/src/Planner/Planner.cpp:1648: DB::Planner::buildPlanForQueryNode() @ 0x000000001497b7aa 18. /build/src/Planner/Planner.cpp:1308: DB::Planner::buildQueryPlanIfNeeded() @ 0x000000001497685c 19. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:255: DB::InterpreterSelectQueryAnalyzer::getQueryPlan() @ 0x000000001497476d 20. /build/src/Interpreters/executeQuery.cpp:1405: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88806 21. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 22. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 23. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 24. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 25. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 26. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 27. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 28. ? @ 0x00007fbc6213eac3 29. ? @ 0x00007fbc621d0850 2025.07.28 12:02:52.473557 [ 17252 ] {} TCPHandler: Code: 43. DB::Exception: Illegal types of arguments: Map(String, UInt8), UInt8 for function arrayElement. (ILLEGAL_TYPE_OF_ARGUMENT), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&) @ 0x000000000a10182b 4. /build/src/Functions/array/arrayElement.cpp:1959: DB::(anonymous namespace)::FunctionArrayElement<(DB::(anonymous namespace)::ArrayElementExceptionMode)0>::executeMap(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000f2baa16 5. /build/src/Functions/array/arrayElement.cpp:2026: DB::(anonymous namespace)::FunctionArrayElement<(DB::(anonymous namespace)::ArrayElementExceptionMode)0>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000f2b6ea5 6. /build/src/Functions/IFunction.h:437: DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000a069f2a 7. /build/src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000012d9965a 8. /build/src/Functions/IFunction.cpp:351: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d93b02 9. /build/src/Functions/IFunction.cpp:420: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d95059 10. /build/src/Functions/IFunction.cpp:498: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d95c72 11. /build/src/Interpreters/ActionsDAG.cpp:812: DB::ActionsDAG::evaluatePartialResult(std::unordered_map, std::equal_to, std::allocator>>&, std::vector> const&, unsigned long, bool) @ 0x0000000013fa38cc 12. /build/src/Interpreters/ActionsDAG.cpp:892: DB::ActionsDAG::updateHeader(DB::Block const&) const @ 0x0000000013fa29a8 13. /build/src/Processors/Transforms/ExpressionTransform.cpp:10: DB::ExpressionTransform::transformHeader(DB::Block const&, DB::ActionsDAG const&) @ 0x0000000016c0afd2 14. /build/src/Processors/QueryPlan/ExpressionStep.cpp:38: DB::ExpressionStep::ExpressionStep(DB::Block const&, DB::ActionsDAG) @ 0x0000000016db8ad1 15. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107](DB::Block const&, DB::ActionsDAG&&) @ 0x00000000131ee01a 16. /build/src/Planner/Planner.cpp:392: DB::(anonymous namespace)::addExpressionStep(DB::QueryPlan&, std::shared_ptr&, String const&, std::unordered_set, std::hash>, std::equal_to>, std::allocator>>&) @ 0x000000001498191d 17. /build/src/Planner/Planner.cpp:1648: DB::Planner::buildPlanForQueryNode() @ 0x000000001497b7aa 18. /build/src/Planner/Planner.cpp:1308: DB::Planner::buildQueryPlanIfNeeded() @ 0x000000001497685c 19. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:255: DB::InterpreterSelectQueryAnalyzer::getQueryPlan() @ 0x000000001497476d 20. /build/src/Interpreters/executeQuery.cpp:1405: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88806 21. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 22. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 23. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 24. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 25. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 26. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 27. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 28. ? @ 0x00007fbc6213eac3 29. ? @ 0x00007fbc621d0850 2025.07.28 12:02:52.489283 [ 4508 ] {4ec177a3-19cb-495f-8493-63df4a801f4d} executeQuery: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=50, jobs=1): While executing MergeTreeSelect(pool: ReadPoolParallelReplicas, algorithm: Thread). (CANNOT_SCHEDULE_TASK) (version 25.3.6.10636.altinitytest (altinity build)) (from [::ffff:127.0.0.1]:56642) (comment: 01072_nullable_jit.sql) (query 5, line 17) (in query: SELECT (sum(`__table1`.`a`) + sum(`__table1`.`b`)) / nullIf(sum(`__table1`.`c`) + sum(`__table1`.`d`), 0) AS `divide(plus(sum(a), sum(b)), nullIf(plus(sum(c), sum(d)), 0))` FROM `test_8gs2stte`.`foo` AS `__table1`), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000fccaeeb 4. /build/src/Common/ThreadPool.cpp:275: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000fccc813 5. /build/src/Common/ThreadPool.cpp:323: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fcc7bbc 6. /build/src/Common/ThreadPool.cpp:494: ThreadPoolImpl>::scheduleOrThrowOnError(std::function, Priority) @ 0x000000000fcc7a0e 7. /build/src/Common/threadPoolCallbackRunner.h:52: std::future> std::__function::__policy_invoker> (DB::MergeTreeMarksLoader::loadMarksAsync()::$_0&&, Priority)>::__call_impl[abi:se190107]> (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&&) @ 0x0000000016474731 8. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000016471940 9. /build/src/Storages/MergeTree/MergeTreeMarksLoader.cpp:83: DB::MergeTreeMarksLoader::startAsyncLoad() @ 0x000000001647173f 10. /build/src/Storages/MergeTree/MergeTreeReaderWide.cpp:294: DB::MergeTreeReaderWide::addStream(DB::ISerialization::SubstreamPath const&, String const&) @ 0x00000000164aa163 11. /build/src/Storages/MergeTree/MergeTreeReaderWide.cpp:251: void std::__function::__policy_invoker::__call_impl[abi:se190107] const&)::$_0, void (DB::ISerialization::SubstreamPath const&)>>(std::__function::__policy_storage const*, DB::ISerialization::SubstreamPath const&) @ 0x00000000164ab3ce 12. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000013c7aa09 13. /build/src/DataTypes/Serializations/ISerialization.cpp:104: DB::ISerialization::enumerateStreams(std::function const&, std::shared_ptr const&, COW::immutable_ptr const&) const @ 0x0000000013c7acfd 14. /build/src/Storages/MergeTree/MergeTreeReaderWide.cpp:255: DB::MergeTreeReaderWide::addStreams(DB::NameAndTypePair const&, std::shared_ptr const&) @ 0x00000000164a83c4 15. /build/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) @ 0x00000000164a81cc 16. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]&, 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&&) @ 0x00000000163cf0e0 17. /build/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 @ 0x00000000163ca51e 18. /build/src/Storages/MergeTree/MergeTreeReadTask.cpp:60: DB::MergeTreeReadTask::createReaders(std::shared_ptr const&, DB::MergeTreeReadTask::Extras const&, DB::MarkRanges const&) @ 0x00000000164b5386 19. /build/src/Storages/MergeTree/MergeTreeReadPoolBase.cpp:274: DB::MergeTreeReadPoolBase::createTask(std::shared_ptr, DB::MarkRanges, DB::MergeTreeReadTask*) const @ 0x0000000016e53b1f 20. /build/src/Storages/MergeTree/MergeTreeReadPoolParallelReplicas.cpp:205: DB::MergeTreeReadPoolParallelReplicas::getTask(unsigned long, DB::MergeTreeReadTask*) @ 0x0000000016e6f59a 21. /build/src/Storages/MergeTree/MergeTreeSelectProcessor.cpp:191: DB::MergeTreeSelectProcessor::read() @ 0x00000000164c0b40 22. /build/src/Storages/MergeTree/MergeTreeSource.cpp:229: DB::MergeTreeSource::tryGenerate() @ 0x0000000016e43d69 23. /build/src/Processors/ISource.cpp:108: DB::ISource::work() @ 0x00000000169a21e7 24. /build/src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x00000000169bd00f 25. /build/src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x00000000169b2105 26. /build/src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeSingleThread(unsigned long) @ 0x00000000169b23be 27. /build/src/Processors/Executors/PipelineExecutor.cpp:454: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x00000000169b0be7 28. /build/src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x00000000169b03f4 29. /build/src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:se190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169bfeab 30. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc3d92 31. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fcca080 2025.07.28 12:02:52.503873 [ 5747 ] {} TCPHandler: Code: 159. DB::Exception: Timeout exceeded: elapsed 63105.156186 ms, maximum: 60000 ms: While executing MergeTreeSelect(pool: ReadPoolInOrder, algorithm: InOrder). (TIMEOUT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, double&&, long&&) @ 0x0000000013bb358b 4. /build/src/QueryPipeline/ExecutionSpeedLimits.cpp:113: DB::ExecutionSpeedLimits::checkTimeLimit(unsigned long const&, DB::OverflowMode) const @ 0x0000000013bb28cc 5. /build/src/QueryPipeline/ReadProgressCallback.cpp:50: DB::ReadProgressCallback::onProgress(unsigned long, unsigned long, std::list> const&) @ 0x0000000013bb1c3d 6. /build/src/Processors/Executors/ExecutionThreadContext.cpp:68: DB::ExecutionThreadContext::executeTask() @ 0x00000000169bd08f 7. /build/src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x00000000169b2105 8. /build/src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeSingleThread(unsigned long) @ 0x00000000169b23be 9. /build/src/Processors/Executors/PipelineExecutor.cpp:416: void std::__function::__policy_invoker::__call_impl[abi:se190107]>(std::__function::__policy_storage const*) @ 0x00000000169b2e3f 10. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc6653 11. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000000fccc4c3 12. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc3d92 13. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fcca080 14. ? @ 0x00007fbc6213eac3 15. ? @ 0x00007fbc621d0850 Job's origin stack trace: 0. /build/src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000000fc33b84 1. /build/src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000000fcc2ea7 2. /build/src/Common/ThreadPool.cpp:401: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fcc7f1c 3. /build/src/Common/ThreadPool.cpp:494: ThreadPoolImpl>::scheduleOrThrowOnError(std::function, Priority) @ 0x000000000fcc7a0e 4. /build/src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::spawnThreadsImpl() @ 0x00000000169b2c0c 5. /build/src/Processors/Executors/PipelineExecutor.cpp:394: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x00000000169b0ba7 6. /build/src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x00000000169b03f4 7. /build/src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:se190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169bfeab 8. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc3d92 9. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fcca080 10. ? @ 0x00007fbc6213eac3 11. ? @ 0x00007fbc621d0850 Job's origin stack trace: 0. /build/src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000000fc33b84 1. /build/src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000000fcc2ea7 2. /build/src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fcc535c 3. /build/src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000000fcc584d 4. /build/src/Common/ThreadPool.h:279: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x00000000169bf193 5. /build/src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x00000000169bf518 6. /build/src/Server/TCPHandler.cpp:1237: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x00000000168f1525 7. /build/src/Server/TCPHandler.cpp:678: DB::TCPHandler::runImpl() @ 0x00000000168e68e5 8. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 9. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 10. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 11. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 12. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 13. ? @ 0x00007fbc6213eac3 14. ? @ 0x00007fbc621d0850 2025.07.28 12:02:52.506642 [ 4508 ] {} TCPHandler: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=50, jobs=1): While executing MergeTreeSelect(pool: ReadPoolParallelReplicas, algorithm: Thread). (CANNOT_SCHEDULE_TASK), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000fccaeeb 4. /build/src/Common/ThreadPool.cpp:275: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000fccc813 5. /build/src/Common/ThreadPool.cpp:323: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fcc7bbc 6. /build/src/Common/ThreadPool.cpp:494: ThreadPoolImpl>::scheduleOrThrowOnError(std::function, Priority) @ 0x000000000fcc7a0e 7. /build/src/Common/threadPoolCallbackRunner.h:52: std::future> std::__function::__policy_invoker> (DB::MergeTreeMarksLoader::loadMarksAsync()::$_0&&, Priority)>::__call_impl[abi:se190107]> (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&&) @ 0x0000000016474731 8. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000016471940 9. /build/src/Storages/MergeTree/MergeTreeMarksLoader.cpp:83: DB::MergeTreeMarksLoader::startAsyncLoad() @ 0x000000001647173f 10. /build/src/Storages/MergeTree/MergeTreeReaderWide.cpp:294: DB::MergeTreeReaderWide::addStream(DB::ISerialization::SubstreamPath const&, String const&) @ 0x00000000164aa163 11. /build/src/Storages/MergeTree/MergeTreeReaderWide.cpp:251: void std::__function::__policy_invoker::__call_impl[abi:se190107] const&)::$_0, void (DB::ISerialization::SubstreamPath const&)>>(std::__function::__policy_storage const*, DB::ISerialization::SubstreamPath const&) @ 0x00000000164ab3ce 12. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000013c7aa09 13. /build/src/DataTypes/Serializations/ISerialization.cpp:104: DB::ISerialization::enumerateStreams(std::function const&, std::shared_ptr const&, COW::immutable_ptr const&) const @ 0x0000000013c7acfd 14. /build/src/Storages/MergeTree/MergeTreeReaderWide.cpp:255: DB::MergeTreeReaderWide::addStreams(DB::NameAndTypePair const&, std::shared_ptr const&) @ 0x00000000164a83c4 15. /build/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) @ 0x00000000164a81cc 16. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]&, 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&&) @ 0x00000000163cf0e0 17. /build/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 @ 0x00000000163ca51e 18. /build/src/Storages/MergeTree/MergeTreeReadTask.cpp:60: DB::MergeTreeReadTask::createReaders(std::shared_ptr const&, DB::MergeTreeReadTask::Extras const&, DB::MarkRanges const&) @ 0x00000000164b5386 19. /build/src/Storages/MergeTree/MergeTreeReadPoolBase.cpp:274: DB::MergeTreeReadPoolBase::createTask(std::shared_ptr, DB::MarkRanges, DB::MergeTreeReadTask*) const @ 0x0000000016e53b1f 20. /build/src/Storages/MergeTree/MergeTreeReadPoolParallelReplicas.cpp:205: DB::MergeTreeReadPoolParallelReplicas::getTask(unsigned long, DB::MergeTreeReadTask*) @ 0x0000000016e6f59a 21. /build/src/Storages/MergeTree/MergeTreeSelectProcessor.cpp:191: DB::MergeTreeSelectProcessor::read() @ 0x00000000164c0b40 22. /build/src/Storages/MergeTree/MergeTreeSource.cpp:229: DB::MergeTreeSource::tryGenerate() @ 0x0000000016e43d69 23. /build/src/Processors/ISource.cpp:108: DB::ISource::work() @ 0x00000000169a21e7 24. /build/src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x00000000169bd00f 25. /build/src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x00000000169b2105 26. /build/src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeSingleThread(unsigned long) @ 0x00000000169b23be 27. /build/src/Processors/Executors/PipelineExecutor.cpp:454: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x00000000169b0be7 28. /build/src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x00000000169b03f4 29. /build/src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:se190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169bfeab 30. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc3d92 31. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fcca080 Job's origin stack trace: 0. /build/src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000000fc33b84 1. /build/src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000000fcc2ea7 2. /build/src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fcc535c 3. /build/src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000000fcc584d 4. /build/src/Common/ThreadPool.h:279: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x00000000169bf193 5. /build/src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x00000000169bf518 6. /build/src/Server/TCPHandler.cpp:1237: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x00000000168f1525 7. /build/src/Server/TCPHandler.cpp:678: DB::TCPHandler::runImpl() @ 0x00000000168e68e5 8. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 9. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 10. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 11. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 12. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 13. ? @ 0x00007fbc6213eac3 14. ? @ 0x00007fbc621d0850 2025.07.28 12:02:52.513824 [ 62065 ] {5ae52fba-4ce0-4d4b-81d7-6a253567c3d3} executeQuery: Code: 439. DB::Exception: Received from 127.0.0.7:9000. DB::Exception: Cannot schedule a task: fault injected (threads=50, jobs=1): While executing MergeTreeSelect(pool: ReadPoolParallelReplicas, algorithm: Thread). Stack trace: 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000fccaeeb 4. /build/src/Common/ThreadPool.cpp:275: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000fccc813 5. /build/src/Common/ThreadPool.cpp:323: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fcc7bbc 6. /build/src/Common/ThreadPool.cpp:494: ThreadPoolImpl>::scheduleOrThrowOnError(std::function, Priority) @ 0x000000000fcc7a0e 7. /build/src/Common/threadPoolCallbackRunner.h:52: std::future> std::__function::__policy_invoker> (DB::MergeTreeMarksLoader::loadMarksAsync()::$_0&&, Priority)>::__call_impl[abi:se190107]> (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&&) @ 0x0000000016474731 8. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000016471940 9. /build/src/Storages/MergeTree/MergeTreeMarksLoader.cpp:83: DB::MergeTreeMarksLoader::startAsyncLoad() @ 0x000000001647173f 10. /build/src/Storages/MergeTree/MergeTreeReaderWide.cpp:294: DB::MergeTreeReaderWide::addStream(DB::ISerialization::SubstreamPath const&, String const&) @ 0x00000000164aa163 11. /build/src/Storages/MergeTree/MergeTreeReaderWide.cpp:251: void std::__function::__policy_invoker::__call_impl[abi:se190107] const&)::$_0, void (DB::ISerialization::SubstreamPath const&)>>(std::__function::__policy_storage const*, DB::ISerialization::SubstreamPath const&) @ 0x00000000164ab3ce 12. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000013c7aa09 13. /build/src/DataTypes/Serializations/ISerialization.cpp:104: DB::ISerialization::enumerateStreams(std::function const&, std::shared_ptr const&, COW::immutable_ptr const&) const @ 0x0000000013c7acfd 14. /build/src/Storages/MergeTree/MergeTreeReaderWide.cpp:255: DB::MergeTreeReaderWide::addStreams(DB::NameAndTypePair const&, std::shared_ptr const&) @ 0x00000000164a83c4 15. /build/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) @ 0x00000000164a81cc 16. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]&, 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&&) @ 0x00000000163cf0e0 17. /build/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 @ 0x00000000163ca51e 18. /build/src/Storages/MergeTree/MergeTreeReadTask.cpp:60: DB::MergeTreeReadTask::createReaders(std::shared_ptr const&, DB::MergeTreeReadTask::Extras const&, DB::MarkRanges const&) @ 0x00000000164b5386 19. /build/src/Storages/MergeTree/MergeTreeReadPoolBase.cpp:274: DB::MergeTreeReadPoolBase::createTask(std::shared_ptr, DB::MarkRanges, DB::MergeTreeReadTask*) const @ 0x0000000016e53b1f 20. /build/src/Storages/MergeTree/MergeTreeReadPoolParallelReplicas.cpp:205: DB::MergeTreeReadPoolParallelReplicas::getTask(unsigned long, DB::MergeTreeReadTask*) @ 0x0000000016e6f59a 21. /build/src/Storages/MergeTree/MergeTreeSelectProcessor.cpp:191: DB::MergeTreeSelectProcessor::read() @ 0x00000000164c0b40 22. /build/src/Storages/MergeTree/MergeTreeSource.cpp:229: DB::MergeTreeSource::tryGenerate() @ 0x0000000016e43d69 23. /build/src/Processors/ISource.cpp:108: DB::ISource::work() @ 0x00000000169a21e7 24. /build/src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x00000000169bd00f 25. /build/src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x00000000169b2105 26. /build/src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeSingleThread(unsigned long) @ 0x00000000169b23be 27. /build/src/Processors/Executors/PipelineExecutor.cpp:454: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x00000000169b0be7 28. /build/src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x00000000169b03f4 29. /build/src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:se190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169bfeab 30. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc3d92 31. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fcca080 Job's origin stack trace: 0. /build/src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000000fc33b84 1. /build/src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000000fcc2ea7 2. /build/src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fcc535c 3. /build/src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000000fcc584d 4. /build/src/Common/ThreadPool.h:279: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x00000000169bf193 5. /build/src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x00000000169bf518 6. /build/src/Server/TCPHandler.cpp:1237: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x00000000168f1525 7. /build/src/Server/TCPHandler.cpp:678: DB::TCPHandler::runImpl() @ 0x00000000168e68e5 8. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 9. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 10. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 11. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 12. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 13. ? @ 0x00007fbc6213eac3 14. ? @ 0x00007fbc621d0850 : While executing Remote. (CANNOT_SCHEDULE_TASK) (version 25.3.6.10636.altinitytest (altinity build)) (from [::1]:49602) (comment: 01072_nullable_jit.sql) (query 5, line 17) (in query: SELECT divide(sum(a) + sum(b), nullIf(sum(c) + sum(d), 0)) FROM foo;), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:111: DB::readException(DB::ReadBuffer&, String const&, bool) @ 0x000000000fc6e157 3. /build/src/Client/Connection.cpp:1445: DB::Connection::receiveException() const @ 0x00000000167d4127 4. /build/src/Client/Connection.cpp:1274: DB::Connection::receivePacket() @ 0x00000000167db312 5. /build/src/Client/MultiplexedConnections.cpp:380: DB::MultiplexedConnections::receivePacketUnlocked(std::function) @ 0x00000000168163a9 6. /build/src/QueryPipeline/RemoteQueryExecutorReadContext.cpp:67: DB::RemoteQueryExecutorReadContext::Task::run(std::function, std::function) @ 0x0000000013bd23fe 7. /build/src/Common/AsyncTaskExecutor.cpp:89: DB::AsyncTaskExecutor::Routine::operator()(std::function) @ 0x0000000013bd1892 8. /build/src/Common/Fiber.h:76: boost::context::detail::fiber_record>::run(void*) @ 0x0000000013bd16fa 9. /build/contrib/boost/boost/context/fiber_fcontext.hpp:97: void boost::context::detail::fiber_entry>>(boost::context::detail::transfer_t) @ 0x0000000013bd1621 2025.07.28 12:02:52.528833 [ 62065 ] {} TCPHandler: Code: 439. DB::Exception: Received from 127.0.0.7:9000. DB::Exception: Cannot schedule a task: fault injected (threads=50, jobs=1): While executing MergeTreeSelect(pool: ReadPoolParallelReplicas, algorithm: Thread). Stack trace: 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000fccaeeb 4. /build/src/Common/ThreadPool.cpp:275: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000fccc813 5. /build/src/Common/ThreadPool.cpp:323: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fcc7bbc 6. /build/src/Common/ThreadPool.cpp:494: ThreadPoolImpl>::scheduleOrThrowOnError(std::function, Priority) @ 0x000000000fcc7a0e 7. /build/src/Common/threadPoolCallbackRunner.h:52: std::future> std::__function::__policy_invoker> (DB::MergeTreeMarksLoader::loadMarksAsync()::$_0&&, Priority)>::__call_impl[abi:se190107]> (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&&) @ 0x0000000016474731 8. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000016471940 9. /build/src/Storages/MergeTree/MergeTreeMarksLoader.cpp:83: DB::MergeTreeMarksLoader::startAsyncLoad() @ 0x000000001647173f 10. /build/src/Storages/MergeTree/MergeTreeReaderWide.cpp:294: DB::MergeTreeReaderWide::addStream(DB::ISerialization::SubstreamPath const&, String const&) @ 0x00000000164aa163 11. /build/src/Storages/MergeTree/MergeTreeReaderWide.cpp:251: void std::__function::__policy_invoker::__call_impl[abi:se190107] const&)::$_0, void (DB::ISerialization::SubstreamPath const&)>>(std::__function::__policy_storage const*, DB::ISerialization::SubstreamPath const&) @ 0x00000000164ab3ce 12. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000013c7aa09 13. /build/src/DataTypes/Serializations/ISerialization.cpp:104: DB::ISerialization::enumerateStreams(std::function const&, std::shared_ptr const&, COW::immutable_ptr const&) const @ 0x0000000013c7acfd 14. /build/src/Storages/MergeTree/MergeTreeReaderWide.cpp:255: DB::MergeTreeReaderWide::addStreams(DB::NameAndTypePair const&, std::shared_ptr const&) @ 0x00000000164a83c4 15. /build/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) @ 0x00000000164a81cc 16. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]&, 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&&) @ 0x00000000163cf0e0 17. /build/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 @ 0x00000000163ca51e 18. /build/src/Storages/MergeTree/MergeTreeReadTask.cpp:60: DB::MergeTreeReadTask::createReaders(std::shared_ptr const&, DB::MergeTreeReadTask::Extras const&, DB::MarkRanges const&) @ 0x00000000164b5386 19. /build/src/Storages/MergeTree/MergeTreeReadPoolBase.cpp:274: DB::MergeTreeReadPoolBase::createTask(std::shared_ptr, DB::MarkRanges, DB::MergeTreeReadTask*) const @ 0x0000000016e53b1f 20. /build/src/Storages/MergeTree/MergeTreeReadPoolParallelReplicas.cpp:205: DB::MergeTreeReadPoolParallelReplicas::getTask(unsigned long, DB::MergeTreeReadTask*) @ 0x0000000016e6f59a 21. /build/src/Storages/MergeTree/MergeTreeSelectProcessor.cpp:191: DB::MergeTreeSelectProcessor::read() @ 0x00000000164c0b40 22. /build/src/Storages/MergeTree/MergeTreeSource.cpp:229: DB::MergeTreeSource::tryGenerate() @ 0x0000000016e43d69 23. /build/src/Processors/ISource.cpp:108: DB::ISource::work() @ 0x00000000169a21e7 24. /build/src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x00000000169bd00f 25. /build/src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x00000000169b2105 26. /build/src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeSingleThread(unsigned long) @ 0x00000000169b23be 27. /build/src/Processors/Executors/PipelineExecutor.cpp:454: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x00000000169b0be7 28. /build/src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x00000000169b03f4 29. /build/src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:se190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169bfeab 30. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc3d92 31. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fcca080 Job's origin stack trace: 0. /build/src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000000fc33b84 1. /build/src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000000fcc2ea7 2. /build/src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fcc535c 3. /build/src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000000fcc584d 4. /build/src/Common/ThreadPool.h:279: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x00000000169bf193 5. /build/src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x00000000169bf518 6. /build/src/Server/TCPHandler.cpp:1237: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x00000000168f1525 7. /build/src/Server/TCPHandler.cpp:678: DB::TCPHandler::runImpl() @ 0x00000000168e68e5 8. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 9. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 10. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 11. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 12. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 13. ? @ 0x00007fbc6213eac3 14. ? @ 0x00007fbc621d0850 : While executing Remote. (CANNOT_SCHEDULE_TASK), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:111: DB::readException(DB::ReadBuffer&, String const&, bool) @ 0x000000000fc6e157 3. /build/src/Client/Connection.cpp:1445: DB::Connection::receiveException() const @ 0x00000000167d4127 4. /build/src/Client/Connection.cpp:1274: DB::Connection::receivePacket() @ 0x00000000167db312 5. /build/src/Client/MultiplexedConnections.cpp:380: DB::MultiplexedConnections::receivePacketUnlocked(std::function) @ 0x00000000168163a9 6. /build/src/QueryPipeline/RemoteQueryExecutorReadContext.cpp:67: DB::RemoteQueryExecutorReadContext::Task::run(std::function, std::function) @ 0x0000000013bd23fe 7. /build/src/Common/AsyncTaskExecutor.cpp:89: DB::AsyncTaskExecutor::Routine::operator()(std::function) @ 0x0000000013bd1892 8. /build/src/Common/Fiber.h:76: boost::context::detail::fiber_record>::run(void*) @ 0x0000000013bd16fa 9. /build/contrib/boost/boost/context/fiber_fcontext.hpp:97: void boost::context::detail::fiber_entry>>(boost::context::detail::transfer_t) @ 0x0000000013bd1621 Job's origin stack trace: 0. /build/src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000000fc33b84 1. /build/src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000000fcc2ea7 2. /build/src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fcc535c 3. /build/src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000000fcc584d 4. /build/src/Common/ThreadPool.h:279: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x00000000169bf193 5. /build/src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x00000000169bf518 6. /build/src/Server/TCPHandler.cpp:1237: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x00000000168f1525 7. /build/src/Server/TCPHandler.cpp:678: DB::TCPHandler::runImpl() @ 0x00000000168e68e5 8. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 9. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 10. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 11. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 12. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 13. ? @ 0x00007fbc6213eac3 14. ? @ 0x00007fbc621d0850 2025.07.28 12:02:52.594458 [ 5029 ] {baeb6857-12af-4022-ac22-06a2a403921d} executeQuery: Code: 210. DB::Exception: I/O error: Broken pipe, while writing to socket ([::ffff:127.0.0.6]:9000 -> [::ffff:127.0.0.1]:45194): While executing MergeTreeSelect(pool: ReadPoolParallelReplicas, algorithm: Thread). (NETWORK_ERROR) (version 25.3.6.10636.altinitytest (altinity build)) (from [::ffff:127.0.0.1]:45194) (comment: 01072_nullable_jit.sql) (query 5, line 17) (in query: SELECT (sum(`__table1`.`a`) + sum(`__table1`.`b`)) / nullIf(sum(`__table1`.`c`) + sum(`__table1`.`d`), 0) AS `divide(plus(sum(a), sum(b)), nullIf(plus(sum(c), sum(d)), 0))` FROM `test_8gs2stte`.`foo` AS `__table1`), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::NetException::NetException(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&) @ 0x000000000fd50fb5 3. /build/src/IO/WriteBufferFromPocoSocket.cpp:171: DB::WriteBufferFromPocoSocket::nextImpl() @ 0x000000000fd525a7 4. /build/src/IO/WriteBuffer.h:53: DB::WriteBuffer::next() @ 0x000000000a0755be 5. /build/src/Server/TCPHandler.cpp:1412: std::optional std::__function::__policy_invoker (DB::ParallelReadRequest)>::__call_impl[abi:se190107] (DB::ParallelReadRequest)>>(std::__function::__policy_storage const*, DB::ParallelReadRequest&&) @ 0x0000000016900423 6. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000164c21d1 7. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000164bec3c 8. /build/src/Storages/MergeTree/MergeTreeReadPoolParallelReplicas.cpp:152: DB::MergeTreeReadPoolParallelReplicas::getTask(unsigned long, DB::MergeTreeReadTask*) @ 0x0000000016e6f646 9. /build/src/Storages/MergeTree/MergeTreeSelectProcessor.cpp:191: DB::MergeTreeSelectProcessor::read() @ 0x00000000164c0b40 10. /build/src/Storages/MergeTree/MergeTreeSource.cpp:229: DB::MergeTreeSource::tryGenerate() @ 0x0000000016e43d69 11. /build/src/Processors/ISource.cpp:108: DB::ISource::work() @ 0x00000000169a21e7 12. /build/src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x00000000169bd00f 13. /build/src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x00000000169b2105 14. /build/src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeSingleThread(unsigned long) @ 0x00000000169b23be 15. /build/src/Processors/Executors/PipelineExecutor.cpp:454: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x00000000169b0be7 16. /build/src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x00000000169b03f4 17. /build/src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:se190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169bfeab 18. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc3d92 19. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fcca080 20. ? @ 0x00007fbc6213eac3 21. ? @ 0x00007fbc621d0850 2025.07.28 12:02:52.612590 [ 5029 ] {} TCPHandler: Code: 210. DB::Exception: I/O error: Broken pipe, while writing to socket ([::ffff:127.0.0.6]:9000 -> [::ffff:127.0.0.1]:45194): While executing MergeTreeSelect(pool: ReadPoolParallelReplicas, algorithm: Thread). (NETWORK_ERROR), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::NetException::NetException(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&) @ 0x000000000fd50fb5 3. /build/src/IO/WriteBufferFromPocoSocket.cpp:171: DB::WriteBufferFromPocoSocket::nextImpl() @ 0x000000000fd525a7 4. /build/src/IO/WriteBuffer.h:53: DB::WriteBuffer::next() @ 0x000000000a0755be 5. /build/src/Server/TCPHandler.cpp:1412: std::optional std::__function::__policy_invoker (DB::ParallelReadRequest)>::__call_impl[abi:se190107] (DB::ParallelReadRequest)>>(std::__function::__policy_storage const*, DB::ParallelReadRequest&&) @ 0x0000000016900423 6. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000164c21d1 7. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000164bec3c 8. /build/src/Storages/MergeTree/MergeTreeReadPoolParallelReplicas.cpp:152: DB::MergeTreeReadPoolParallelReplicas::getTask(unsigned long, DB::MergeTreeReadTask*) @ 0x0000000016e6f646 9. /build/src/Storages/MergeTree/MergeTreeSelectProcessor.cpp:191: DB::MergeTreeSelectProcessor::read() @ 0x00000000164c0b40 10. /build/src/Storages/MergeTree/MergeTreeSource.cpp:229: DB::MergeTreeSource::tryGenerate() @ 0x0000000016e43d69 11. /build/src/Processors/ISource.cpp:108: DB::ISource::work() @ 0x00000000169a21e7 12. /build/src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x00000000169bd00f 13. /build/src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x00000000169b2105 14. /build/src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeSingleThread(unsigned long) @ 0x00000000169b23be 15. /build/src/Processors/Executors/PipelineExecutor.cpp:454: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x00000000169b0be7 16. /build/src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x00000000169b03f4 17. /build/src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:se190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169bfeab 18. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc3d92 19. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fcca080 20. ? @ 0x00007fbc6213eac3 21. ? @ 0x00007fbc621d0850 Job's origin stack trace: 0. /build/src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000000fc33b84 1. /build/src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000000fcc2ea7 2. /build/src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fcc535c 3. /build/src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000000fcc584d 4. /build/src/Common/ThreadPool.h:279: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x00000000169bf193 5. /build/src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x00000000169bf518 6. /build/src/Server/TCPHandler.cpp:1237: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x00000000168f1525 7. /build/src/Server/TCPHandler.cpp:678: DB::TCPHandler::runImpl() @ 0x00000000168e68e5 8. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 9. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 10. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 11. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 12. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 13. ? @ 0x00007fbc6213eac3 14. ? @ 0x00007fbc621d0850 2025.07.28 12:02:52.642792 [ 3960 ] {} test_13.rmt2 (7f9b740d-015c-470e-8cc6-8ba33be0dc63): auto DB::StorageReplicatedMergeTree::processQueueEntry(ReplicatedMergeTreeQueue::SelectedEntryPtr)::(anonymous class)::operator()(LogEntryPtr &) const: Code: 86. DB::HTTPException: Received error from remote server http://146b4357c08d:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Ftest%2F01165%2Ftest_13%2Frmt%2Freplicas%2F1&part=20250728_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.6.10636.altinitytest (altinity build)) '. (RECEIVED_ERROR_FROM_REMOTE_IO_SERVER), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.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 const&, int&&, String const&, unsigned long&&, String const&) @ 0x000000000feda8d9 4. /build/src/IO/HTTPCommon.cpp:104: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x000000000feda6e2 5. /build/src/IO/HTTPCommon.cpp:93: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x000000000feda537 6. /build/src/IO/ReadWriteBufferFromHTTP.cpp:277: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x000000001184a4c4 7. /build/src/IO/ReadWriteBufferFromHTTP.cpp:285: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x000000001184a615 8. /build/src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x000000001184ae59 9. /build/src/IO/ReadWriteBufferFromHTTP.cpp:472: void std::__function::__policy_invoker::__call_impl[abi:se190107]>(std::__function::__policy_storage const*) @ 0x000000001184cedd 10. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001184858b 11. /build/src/IO/ReadWriteBufferFromHTTP.cpp:465: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x000000001184bf0b 12. /build/src/IO/ReadBuffer.h:60: DB::ReadBuffer::next() @ 0x000000000a148c7b 13. /build/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) @ 0x0000000011849fb2 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]>&)>&, 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&) @ 0x0000000011841980 15. /build/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) @ 0x000000001621208e 16. /build/src/Storages/StorageReplicatedMergeTree.cpp:5228: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl[abi:se190107] const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000015f9a5fe 17. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000015ed8bfd 18. /build/src/Storages/StorageReplicatedMergeTree.cpp:2514: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x0000000015ec9aab 19. /build/src/Storages/StorageReplicatedMergeTree.cpp:2349: DB::StorageReplicatedMergeTree::executeLogEntry(DB::ReplicatedMergeTreeLogEntry&) @ 0x0000000015eba91b 20. /build/src/Storages/StorageReplicatedMergeTree.cpp:3876: bool std::__function::__policy_invoker&)>::__call_impl[abi:se190107])::$_1, bool (std::shared_ptr&)>>(std::__function::__policy_storage const*, std::shared_ptr&) @ 0x0000000015f9837e 21. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000165d6fc3 22. /build/src/Storages/StorageReplicatedMergeTree.cpp:3872: DB::StorageReplicatedMergeTree::processQueueEntry(std::shared_ptr) @ 0x0000000015efc18a 23. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001624c1b2 24. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000162f9c70 25. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x00000000162fa55a 26. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc6653 27. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000000fccc4c3 28. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc3d92 29. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fcca080 30. ? @ 0x00007fbc6213eac3 31. ? @ 0x00007fbc621d0850 (version 25.3.6.10636.altinitytest (altinity build)) 2025.07.28 12:02:53.419472 [ 3971 ] {} test_13.rmt2 (7f9b740d-015c-470e-8cc6-8ba33be0dc63): auto DB::StorageReplicatedMergeTree::processQueueEntry(ReplicatedMergeTreeQueue::SelectedEntryPtr)::(anonymous class)::operator()(LogEntryPtr &) const: Code: 86. DB::HTTPException: Received error from remote server http://146b4357c08d:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Ftest%2F01165%2Ftest_13%2Frmt%2Freplicas%2F1&part=20250728_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.6.10636.altinitytest (altinity build)) '. (RECEIVED_ERROR_FROM_REMOTE_IO_SERVER), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.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 const&, int&&, String const&, unsigned long&&, String const&) @ 0x000000000feda8d9 4. /build/src/IO/HTTPCommon.cpp:104: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x000000000feda6e2 5. /build/src/IO/HTTPCommon.cpp:93: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x000000000feda537 6. /build/src/IO/ReadWriteBufferFromHTTP.cpp:277: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x000000001184a4c4 7. /build/src/IO/ReadWriteBufferFromHTTP.cpp:285: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x000000001184a615 8. /build/src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x000000001184ae59 9. /build/src/IO/ReadWriteBufferFromHTTP.cpp:472: void std::__function::__policy_invoker::__call_impl[abi:se190107]>(std::__function::__policy_storage const*) @ 0x000000001184cedd 10. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001184858b 11. /build/src/IO/ReadWriteBufferFromHTTP.cpp:465: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x000000001184bf0b 12. /build/src/IO/ReadBuffer.h:60: DB::ReadBuffer::next() @ 0x000000000a148c7b 13. /build/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) @ 0x0000000011849fb2 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]>&)>&, 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&) @ 0x0000000011841980 15. /build/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) @ 0x000000001621208e 16. /build/src/Storages/StorageReplicatedMergeTree.cpp:5228: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl[abi:se190107] const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000015f9a5fe 17. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000015ed8bfd 18. /build/src/Storages/StorageReplicatedMergeTree.cpp:2514: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x0000000015ec9aab 19. /build/src/Storages/StorageReplicatedMergeTree.cpp:2349: DB::StorageReplicatedMergeTree::executeLogEntry(DB::ReplicatedMergeTreeLogEntry&) @ 0x0000000015eba91b 20. /build/src/Storages/StorageReplicatedMergeTree.cpp:3876: bool std::__function::__policy_invoker&)>::__call_impl[abi:se190107])::$_1, bool (std::shared_ptr&)>>(std::__function::__policy_storage const*, std::shared_ptr&) @ 0x0000000015f9837e 21. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000165d6fc3 22. /build/src/Storages/StorageReplicatedMergeTree.cpp:3872: DB::StorageReplicatedMergeTree::processQueueEntry(std::shared_ptr) @ 0x0000000015efc18a 23. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001624c1b2 24. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000162f9c70 25. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x00000000162fa55a 26. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc6653 27. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000000fccc4c3 28. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc3d92 29. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fcca080 30. ? @ 0x00007fbc6213eac3 31. ? @ 0x00007fbc621d0850 (version 25.3.6.10636.altinitytest (altinity build)) 2025.07.28 12:02:53.762499 [ 3966 ] {} test_13.rmt2 (7f9b740d-015c-470e-8cc6-8ba33be0dc63): auto DB::StorageReplicatedMergeTree::processQueueEntry(ReplicatedMergeTreeQueue::SelectedEntryPtr)::(anonymous class)::operator()(LogEntryPtr &) const: Code: 86. DB::HTTPException: Received error from remote server http://146b4357c08d:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Ftest%2F01165%2Ftest_13%2Frmt%2Freplicas%2F1&part=20250728_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.6.10636.altinitytest (altinity build)) '. (RECEIVED_ERROR_FROM_REMOTE_IO_SERVER), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.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 const&, int&&, String const&, unsigned long&&, String const&) @ 0x000000000feda8d9 4. /build/src/IO/HTTPCommon.cpp:104: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x000000000feda6e2 5. /build/src/IO/HTTPCommon.cpp:93: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x000000000feda537 6. /build/src/IO/ReadWriteBufferFromHTTP.cpp:277: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x000000001184a4c4 7. /build/src/IO/ReadWriteBufferFromHTTP.cpp:285: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x000000001184a615 8. /build/src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x000000001184ae59 9. /build/src/IO/ReadWriteBufferFromHTTP.cpp:472: void std::__function::__policy_invoker::__call_impl[abi:se190107]>(std::__function::__policy_storage const*) @ 0x000000001184cedd 10. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001184858b 11. /build/src/IO/ReadWriteBufferFromHTTP.cpp:465: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x000000001184bf0b 12. /build/src/IO/ReadBuffer.h:60: DB::ReadBuffer::next() @ 0x000000000a148c7b 13. /build/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) @ 0x0000000011849fb2 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]>&)>&, 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&) @ 0x0000000011841980 15. /build/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) @ 0x000000001621208e 16. /build/src/Storages/StorageReplicatedMergeTree.cpp:5228: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl[abi:se190107] const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000015f9a5fe 17. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000015ed8bfd 18. /build/src/Storages/StorageReplicatedMergeTree.cpp:2514: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x0000000015ec9aab 19. /build/src/Storages/StorageReplicatedMergeTree.cpp:2349: DB::StorageReplicatedMergeTree::executeLogEntry(DB::ReplicatedMergeTreeLogEntry&) @ 0x0000000015eba91b 20. /build/src/Storages/StorageReplicatedMergeTree.cpp:3876: bool std::__function::__policy_invoker&)>::__call_impl[abi:se190107])::$_1, bool (std::shared_ptr&)>>(std::__function::__policy_storage const*, std::shared_ptr&) @ 0x0000000015f9837e 21. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000165d6fc3 22. /build/src/Storages/StorageReplicatedMergeTree.cpp:3872: DB::StorageReplicatedMergeTree::processQueueEntry(std::shared_ptr) @ 0x0000000015efc18a 23. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001624c1b2 24. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000162f9c70 25. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x00000000162fa55a 26. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc6653 27. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000000fccc4c3 28. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc3d92 29. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fcca080 30. ? @ 0x00007fbc6213eac3 31. ? @ 0x00007fbc621d0850 (version 25.3.6.10636.altinitytest (altinity build)) 2025.07.28 12:02:54.220369 [ 3974 ] {} test_13.rmt2 (7f9b740d-015c-470e-8cc6-8ba33be0dc63): auto DB::StorageReplicatedMergeTree::processQueueEntry(ReplicatedMergeTreeQueue::SelectedEntryPtr)::(anonymous class)::operator()(LogEntryPtr &) const: Code: 86. DB::HTTPException: Received error from remote server http://146b4357c08d:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Ftest%2F01165%2Ftest_13%2Frmt%2Freplicas%2F1&part=20250728_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.6.10636.altinitytest (altinity build)) '. (RECEIVED_ERROR_FROM_REMOTE_IO_SERVER), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.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 const&, int&&, String const&, unsigned long&&, String const&) @ 0x000000000feda8d9 4. /build/src/IO/HTTPCommon.cpp:104: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x000000000feda6e2 5. /build/src/IO/HTTPCommon.cpp:93: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x000000000feda537 6. /build/src/IO/ReadWriteBufferFromHTTP.cpp:277: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x000000001184a4c4 7. /build/src/IO/ReadWriteBufferFromHTTP.cpp:285: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x000000001184a615 8. /build/src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x000000001184ae59 9. /build/src/IO/ReadWriteBufferFromHTTP.cpp:472: void std::__function::__policy_invoker::__call_impl[abi:se190107]>(std::__function::__policy_storage const*) @ 0x000000001184cedd 10. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001184858b 11. /build/src/IO/ReadWriteBufferFromHTTP.cpp:465: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x000000001184bf0b 12. /build/src/IO/ReadBuffer.h:60: DB::ReadBuffer::next() @ 0x000000000a148c7b 13. /build/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) @ 0x0000000011849fb2 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]>&)>&, 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&) @ 0x0000000011841980 15. /build/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) @ 0x000000001621208e 16. /build/src/Storages/StorageReplicatedMergeTree.cpp:5228: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl[abi:se190107] const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000015f9a5fe 17. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000015ed8bfd 18. /build/src/Storages/StorageReplicatedMergeTree.cpp:2514: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x0000000015ec9aab 19. /build/src/Storages/StorageReplicatedMergeTree.cpp:2349: DB::StorageReplicatedMergeTree::executeLogEntry(DB::ReplicatedMergeTreeLogEntry&) @ 0x0000000015eba91b 20. /build/src/Storages/StorageReplicatedMergeTree.cpp:3876: bool std::__function::__policy_invoker&)>::__call_impl[abi:se190107])::$_1, bool (std::shared_ptr&)>>(std::__function::__policy_storage const*, std::shared_ptr&) @ 0x0000000015f9837e 21. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000165d6fc3 22. /build/src/Storages/StorageReplicatedMergeTree.cpp:3872: DB::StorageReplicatedMergeTree::processQueueEntry(std::shared_ptr) @ 0x0000000015efc18a 23. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001624c1b2 24. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000162f9c70 25. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x00000000162fa55a 26. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc6653 27. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000000fccc4c3 28. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc3d92 29. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fcca080 30. ? @ 0x00007fbc6213eac3 31. ? @ 0x00007fbc621d0850 (version 25.3.6.10636.altinitytest (altinity build)) 2025.07.28 12:02:54.778972 [ 62065 ] {18dcc682-1e61-4b4c-bbc8-eb7b4b0e81e0} executeQuery: Code: 36. DB::Exception: Frame start offset 2 FOLLOWING does not precede the frame end offset 0 FOLLOWING. (BAD_ARGUMENTS) (version 25.3.6.10636.altinitytest (altinity build)) (from [::1]:59004) (comment: 01571_window_functions.sql) (query 10, line 32) (in query: -- signed and unsigned in offset do not cause logical error select count() over (rows between 2 following and 1 + -1 following) FROM numbers(10);), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, DB::Field const&, char const (&) [10], DB::Field const&, char const (&) [10]) @ 0x0000000014c47f6b 4. /build/src/Interpreters/WindowDescription.cpp:179: DB::WindowFrame::checkValid() const @ 0x0000000014c47be9 5. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:2565: DB::QueryAnalyzer::resolveWindow(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000001403ef58 6. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3291: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000014031889 7. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3838: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000014019a9e 8. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3980: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000014018e31 9. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:4304: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000014042fa7 10. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5605: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000014013749 11. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000140127f9 12. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000014011fce 13. /build/src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000001406ce8a 14. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000014973b42 15. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000001497268d 16. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000014974d24 17. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001492924b 18. /build/src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88641 19. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 20. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 21. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 22. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 23. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 24. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 25. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 26. ? @ 0x00007fbc6213eac3 27. ? @ 0x00007fbc621d0850 2025.07.28 12:02:54.783842 [ 62065 ] {} TCPHandler: Code: 36. DB::Exception: Frame start offset 2 FOLLOWING does not precede the frame end offset 0 FOLLOWING. (BAD_ARGUMENTS), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, DB::Field const&, char const (&) [10], DB::Field const&, char const (&) [10]) @ 0x0000000014c47f6b 4. /build/src/Interpreters/WindowDescription.cpp:179: DB::WindowFrame::checkValid() const @ 0x0000000014c47be9 5. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:2565: DB::QueryAnalyzer::resolveWindow(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000001403ef58 6. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3291: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000014031889 7. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3838: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000014019a9e 8. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3980: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000014018e31 9. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:4304: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000014042fa7 10. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5605: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000014013749 11. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000140127f9 12. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000014011fce 13. /build/src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000001406ce8a 14. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000014973b42 15. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000001497268d 16. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000014974d24 17. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001492924b 18. /build/src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88641 19. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 20. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 21. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 22. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 23. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 24. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 25. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 26. ? @ 0x00007fbc6213eac3 27. ? @ 0x00007fbc621d0850 2025.07.28 12:02:55.146841 [ 3968 ] {} test_13.rmt2 (7f9b740d-015c-470e-8cc6-8ba33be0dc63): auto DB::StorageReplicatedMergeTree::processQueueEntry(ReplicatedMergeTreeQueue::SelectedEntryPtr)::(anonymous class)::operator()(LogEntryPtr &) const: Code: 86. DB::HTTPException: Received error from remote server http://146b4357c08d:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Ftest%2F01165%2Ftest_13%2Frmt%2Freplicas%2F1&part=20250728_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.6.10636.altinitytest (altinity build)) '. (RECEIVED_ERROR_FROM_REMOTE_IO_SERVER), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.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 const&, int&&, String const&, unsigned long&&, String const&) @ 0x000000000feda8d9 4. /build/src/IO/HTTPCommon.cpp:104: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x000000000feda6e2 5. /build/src/IO/HTTPCommon.cpp:93: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x000000000feda537 6. /build/src/IO/ReadWriteBufferFromHTTP.cpp:277: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x000000001184a4c4 7. /build/src/IO/ReadWriteBufferFromHTTP.cpp:285: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x000000001184a615 8. /build/src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x000000001184ae59 9. /build/src/IO/ReadWriteBufferFromHTTP.cpp:472: void std::__function::__policy_invoker::__call_impl[abi:se190107]>(std::__function::__policy_storage const*) @ 0x000000001184cedd 10. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001184858b 11. /build/src/IO/ReadWriteBufferFromHTTP.cpp:465: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x000000001184bf0b 12. /build/src/IO/ReadBuffer.h:60: DB::ReadBuffer::next() @ 0x000000000a148c7b 13. /build/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) @ 0x0000000011849fb2 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]>&)>&, 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&) @ 0x0000000011841980 15. /build/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) @ 0x000000001621208e 16. /build/src/Storages/StorageReplicatedMergeTree.cpp:5228: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl[abi:se190107] const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000015f9a5fe 17. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000015ed8bfd 18. /build/src/Storages/StorageReplicatedMergeTree.cpp:2514: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x0000000015ec9aab 19. /build/src/Storages/StorageReplicatedMergeTree.cpp:2349: DB::StorageReplicatedMergeTree::executeLogEntry(DB::ReplicatedMergeTreeLogEntry&) @ 0x0000000015eba91b 20. /build/src/Storages/StorageReplicatedMergeTree.cpp:3876: bool std::__function::__policy_invoker&)>::__call_impl[abi:se190107])::$_1, bool (std::shared_ptr&)>>(std::__function::__policy_storage const*, std::shared_ptr&) @ 0x0000000015f9837e 21. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000165d6fc3 22. /build/src/Storages/StorageReplicatedMergeTree.cpp:3872: DB::StorageReplicatedMergeTree::processQueueEntry(std::shared_ptr) @ 0x0000000015efc18a 23. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001624c1b2 24. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000162f9c70 25. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x00000000162fa55a 26. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc6653 27. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000000fccc4c3 28. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc3d92 29. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fcca080 30. ? @ 0x00007fbc6213eac3 31. ? @ 0x00007fbc621d0850 (version 25.3.6.10636.altinitytest (altinity build)) 2025.07.28 12:02:55.717232 [ 3967 ] {} test_13.rmt2 (7f9b740d-015c-470e-8cc6-8ba33be0dc63): auto DB::StorageReplicatedMergeTree::processQueueEntry(ReplicatedMergeTreeQueue::SelectedEntryPtr)::(anonymous class)::operator()(LogEntryPtr &) const: Code: 86. DB::HTTPException: Received error from remote server http://146b4357c08d:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Ftest%2F01165%2Ftest_13%2Frmt%2Freplicas%2F1&part=20250728_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.6.10636.altinitytest (altinity build)) '. (RECEIVED_ERROR_FROM_REMOTE_IO_SERVER), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.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 const&, int&&, String const&, unsigned long&&, String const&) @ 0x000000000feda8d9 4. /build/src/IO/HTTPCommon.cpp:104: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x000000000feda6e2 5. /build/src/IO/HTTPCommon.cpp:93: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x000000000feda537 6. /build/src/IO/ReadWriteBufferFromHTTP.cpp:277: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x000000001184a4c4 7. /build/src/IO/ReadWriteBufferFromHTTP.cpp:285: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x000000001184a615 8. /build/src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x000000001184ae59 9. /build/src/IO/ReadWriteBufferFromHTTP.cpp:472: void std::__function::__policy_invoker::__call_impl[abi:se190107]>(std::__function::__policy_storage const*) @ 0x000000001184cedd 10. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001184858b 11. /build/src/IO/ReadWriteBufferFromHTTP.cpp:465: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x000000001184bf0b 12. /build/src/IO/ReadBuffer.h:60: DB::ReadBuffer::next() @ 0x000000000a148c7b 13. /build/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) @ 0x0000000011849fb2 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]>&)>&, 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&) @ 0x0000000011841980 15. /build/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) @ 0x000000001621208e 16. /build/src/Storages/StorageReplicatedMergeTree.cpp:5228: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl[abi:se190107] const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000015f9a5fe 17. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000015ed8bfd 18. /build/src/Storages/StorageReplicatedMergeTree.cpp:2514: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x0000000015ec9aab 19. /build/src/Storages/StorageReplicatedMergeTree.cpp:2349: DB::StorageReplicatedMergeTree::executeLogEntry(DB::ReplicatedMergeTreeLogEntry&) @ 0x0000000015eba91b 20. /build/src/Storages/StorageReplicatedMergeTree.cpp:3876: bool std::__function::__policy_invoker&)>::__call_impl[abi:se190107])::$_1, bool (std::shared_ptr&)>>(std::__function::__policy_storage const*, std::shared_ptr&) @ 0x0000000015f9837e 21. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000165d6fc3 22. /build/src/Storages/StorageReplicatedMergeTree.cpp:3872: DB::StorageReplicatedMergeTree::processQueueEntry(std::shared_ptr) @ 0x0000000015efc18a 23. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001624c1b2 24. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000162f9c70 25. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x00000000162fa55a 26. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc6653 27. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000000fccc4c3 28. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc3d92 29. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fcca080 30. ? @ 0x00007fbc6213eac3 31. ? @ 0x00007fbc621d0850 (version 25.3.6.10636.altinitytest (altinity build)) 2025.07.28 12:02:55.965102 [ 4446 ] {6fd61c8c-4ac0-4501-b82e-69cead456323} executeQuery: Code: 57. DB::Exception: Table test_kczuwzn4.t already exists. (TABLE_ALREADY_EXISTS) (version 25.3.6.10636.altinitytest (altinity build)) (from [::1]:59204) (comment: 02792_alter_table_modify_comment.sql) (query 7, line 14) (in query: CREATE TABLE t (`x` UInt8) ENGINE = MergeTree ORDER BY tuple() SETTINGS index_granularity = 15288, min_bytes_for_wide_part = 104866427, 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 = 359866466, compact_parts_max_bytes_to_buffer = 526658196, compact_parts_max_granules_to_buffer = 244, compact_parts_merge_max_bytes_to_prefetch_part = 26687054, merge_max_block_size = 9982, old_parts_lifetime = 10., 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 = 1, index_granularity_bytes = 15548311, use_const_adaptive_granularity = false, enable_index_granularity_compression = false, concurrent_part_removal_threshold = 25, allow_vertical_merges_from_compact_to_wide_parts = true, enable_block_number_column = true, enable_block_offset_column = true, cache_populated_by_fetch = false, marks_compress_block_size = 18886, primary_key_compress_block_size = 72544, use_primary_key_cache = false, prewarm_primary_key_cache = true, prewarm_mark_cache = true COMMENT 'Hello'), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000a06a8eb 4. /build/src/Interpreters/InterpreterCreateQuery.cpp:1824: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x0000000014901d53 5. /build/src/Interpreters/InterpreterCreateQuery.cpp:1743: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000148f9aa9 6. /build/src/Interpreters/InterpreterCreateQuery.cpp:2352: DB::InterpreterCreateQuery::execute() @ 0x0000000014905a41 7. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88dc9 8. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 9. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 10. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 11. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 12. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 13. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 14. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 15. ? @ 0x00007fbc6213eac3 16. ? @ 0x00007fbc621d0850 2025.07.28 12:02:55.986610 [ 4446 ] {} TCPHandler: Code: 57. DB::Exception: Table test_kczuwzn4.t already exists. (TABLE_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000a06a8eb 4. /build/src/Interpreters/InterpreterCreateQuery.cpp:1824: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x0000000014901d53 5. /build/src/Interpreters/InterpreterCreateQuery.cpp:1743: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000148f9aa9 6. /build/src/Interpreters/InterpreterCreateQuery.cpp:2352: DB::InterpreterCreateQuery::execute() @ 0x0000000014905a41 7. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88dc9 8. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 9. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 10. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 11. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 12. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 13. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 14. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 15. ? @ 0x00007fbc6213eac3 16. ? @ 0x00007fbc621d0850 2025.07.28 12:02:56.080047 [ 3961 ] {} test_13.rmt2 (7f9b740d-015c-470e-8cc6-8ba33be0dc63): auto DB::StorageReplicatedMergeTree::processQueueEntry(ReplicatedMergeTreeQueue::SelectedEntryPtr)::(anonymous class)::operator()(LogEntryPtr &) const: Code: 86. DB::HTTPException: Received error from remote server http://146b4357c08d:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Ftest%2F01165%2Ftest_13%2Frmt%2Freplicas%2F1&part=20250728_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.6.10636.altinitytest (altinity build)) '. (RECEIVED_ERROR_FROM_REMOTE_IO_SERVER), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.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 const&, int&&, String const&, unsigned long&&, String const&) @ 0x000000000feda8d9 4. /build/src/IO/HTTPCommon.cpp:104: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x000000000feda6e2 5. /build/src/IO/HTTPCommon.cpp:93: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x000000000feda537 6. /build/src/IO/ReadWriteBufferFromHTTP.cpp:277: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x000000001184a4c4 7. /build/src/IO/ReadWriteBufferFromHTTP.cpp:285: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x000000001184a615 8. /build/src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x000000001184ae59 9. /build/src/IO/ReadWriteBufferFromHTTP.cpp:472: void std::__function::__policy_invoker::__call_impl[abi:se190107]>(std::__function::__policy_storage const*) @ 0x000000001184cedd 10. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001184858b 11. /build/src/IO/ReadWriteBufferFromHTTP.cpp:465: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x000000001184bf0b 12. /build/src/IO/ReadBuffer.h:60: DB::ReadBuffer::next() @ 0x000000000a148c7b 13. /build/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) @ 0x0000000011849fb2 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]>&)>&, 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&) @ 0x0000000011841980 15. /build/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) @ 0x000000001621208e 16. /build/src/Storages/StorageReplicatedMergeTree.cpp:5228: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl[abi:se190107] const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000015f9a5fe 17. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000015ed8bfd 18. /build/src/Storages/StorageReplicatedMergeTree.cpp:2514: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x0000000015ec9aab 19. /build/src/Storages/StorageReplicatedMergeTree.cpp:2349: DB::StorageReplicatedMergeTree::executeLogEntry(DB::ReplicatedMergeTreeLogEntry&) @ 0x0000000015eba91b 20. /build/src/Storages/StorageReplicatedMergeTree.cpp:3876: bool std::__function::__policy_invoker&)>::__call_impl[abi:se190107])::$_1, bool (std::shared_ptr&)>>(std::__function::__policy_storage const*, std::shared_ptr&) @ 0x0000000015f9837e 21. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000165d6fc3 22. /build/src/Storages/StorageReplicatedMergeTree.cpp:3872: DB::StorageReplicatedMergeTree::processQueueEntry(std::shared_ptr) @ 0x0000000015efc18a 23. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001624c1b2 24. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000162f9c70 25. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x00000000162fa55a 26. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc6653 27. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000000fccc4c3 28. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc3d92 29. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fcca080 30. ? @ 0x00007fbc6213eac3 31. ? @ 0x00007fbc621d0850 (version 25.3.6.10636.altinitytest (altinity build)) 2025.07.28 12:02:56.203425 [ 3972 ] {} test_13.rmt2 (7f9b740d-015c-470e-8cc6-8ba33be0dc63): auto DB::StorageReplicatedMergeTree::processQueueEntry(ReplicatedMergeTreeQueue::SelectedEntryPtr)::(anonymous class)::operator()(LogEntryPtr &) const: Code: 86. DB::HTTPException: Received error from remote server http://146b4357c08d:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Ftest%2F01165%2Ftest_13%2Frmt%2Freplicas%2F1&part=20250728_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.6.10636.altinitytest (altinity build)) '. (RECEIVED_ERROR_FROM_REMOTE_IO_SERVER), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.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 const&, int&&, String const&, unsigned long&&, String const&) @ 0x000000000feda8d9 4. /build/src/IO/HTTPCommon.cpp:104: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x000000000feda6e2 5. /build/src/IO/HTTPCommon.cpp:93: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x000000000feda537 6. /build/src/IO/ReadWriteBufferFromHTTP.cpp:277: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x000000001184a4c4 7. /build/src/IO/ReadWriteBufferFromHTTP.cpp:285: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x000000001184a615 8. /build/src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x000000001184ae59 9. /build/src/IO/ReadWriteBufferFromHTTP.cpp:472: void std::__function::__policy_invoker::__call_impl[abi:se190107]>(std::__function::__policy_storage const*) @ 0x000000001184cedd 10. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001184858b 11. /build/src/IO/ReadWriteBufferFromHTTP.cpp:465: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x000000001184bf0b 12. /build/src/IO/ReadBuffer.h:60: DB::ReadBuffer::next() @ 0x000000000a148c7b 13. /build/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) @ 0x0000000011849fb2 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]>&)>&, 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&) @ 0x0000000011841980 15. /build/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) @ 0x000000001621208e 16. /build/src/Storages/StorageReplicatedMergeTree.cpp:5228: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl[abi:se190107] const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000015f9a5fe 17. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000015ed8bfd 18. /build/src/Storages/StorageReplicatedMergeTree.cpp:2514: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x0000000015ec9aab 19. /build/src/Storages/StorageReplicatedMergeTree.cpp:2349: DB::StorageReplicatedMergeTree::executeLogEntry(DB::ReplicatedMergeTreeLogEntry&) @ 0x0000000015eba91b 20. /build/src/Storages/StorageReplicatedMergeTree.cpp:3876: bool std::__function::__policy_invoker&)>::__call_impl[abi:se190107])::$_1, bool (std::shared_ptr&)>>(std::__function::__policy_storage const*, std::shared_ptr&) @ 0x0000000015f9837e 21. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000165d6fc3 22. /build/src/Storages/StorageReplicatedMergeTree.cpp:3872: DB::StorageReplicatedMergeTree::processQueueEntry(std::shared_ptr) @ 0x0000000015efc18a 23. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001624c1b2 24. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000162f9c70 25. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x00000000162fa55a 26. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc6653 27. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000000fccc4c3 28. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc3d92 29. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fcca080 30. ? @ 0x00007fbc6213eac3 31. ? @ 0x00007fbc621d0850 (version 25.3.6.10636.altinitytest (altinity build)) 2025.07.28 12:02:56.699781 [ 3960 ] {} test_13.rmt2 (7f9b740d-015c-470e-8cc6-8ba33be0dc63): auto DB::StorageReplicatedMergeTree::processQueueEntry(ReplicatedMergeTreeQueue::SelectedEntryPtr)::(anonymous class)::operator()(LogEntryPtr &) const: Code: 86. DB::HTTPException: Received error from remote server http://146b4357c08d:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Ftest%2F01165%2Ftest_13%2Frmt%2Freplicas%2F1&part=20250728_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.6.10636.altinitytest (altinity build)) '. (RECEIVED_ERROR_FROM_REMOTE_IO_SERVER), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.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 const&, int&&, String const&, unsigned long&&, String const&) @ 0x000000000feda8d9 4. /build/src/IO/HTTPCommon.cpp:104: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x000000000feda6e2 5. /build/src/IO/HTTPCommon.cpp:93: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x000000000feda537 6. /build/src/IO/ReadWriteBufferFromHTTP.cpp:277: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x000000001184a4c4 7. /build/src/IO/ReadWriteBufferFromHTTP.cpp:285: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x000000001184a615 8. /build/src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x000000001184ae59 9. /build/src/IO/ReadWriteBufferFromHTTP.cpp:472: void std::__function::__policy_invoker::__call_impl[abi:se190107]>(std::__function::__policy_storage const*) @ 0x000000001184cedd 10. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001184858b 11. /build/src/IO/ReadWriteBufferFromHTTP.cpp:465: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x000000001184bf0b 12. /build/src/IO/ReadBuffer.h:60: DB::ReadBuffer::next() @ 0x000000000a148c7b 13. /build/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) @ 0x0000000011849fb2 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]>&)>&, 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&) @ 0x0000000011841980 15. /build/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) @ 0x000000001621208e 16. /build/src/Storages/StorageReplicatedMergeTree.cpp:5228: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl[abi:se190107] const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000015f9a5fe 17. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000015ed8bfd 18. /build/src/Storages/StorageReplicatedMergeTree.cpp:2514: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x0000000015ec9aab 19. /build/src/Storages/StorageReplicatedMergeTree.cpp:2349: DB::StorageReplicatedMergeTree::executeLogEntry(DB::ReplicatedMergeTreeLogEntry&) @ 0x0000000015eba91b 20. /build/src/Storages/StorageReplicatedMergeTree.cpp:3876: bool std::__function::__policy_invoker&)>::__call_impl[abi:se190107])::$_1, bool (std::shared_ptr&)>>(std::__function::__policy_storage const*, std::shared_ptr&) @ 0x0000000015f9837e 21. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000165d6fc3 22. /build/src/Storages/StorageReplicatedMergeTree.cpp:3872: DB::StorageReplicatedMergeTree::processQueueEntry(std::shared_ptr) @ 0x0000000015efc18a 23. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001624c1b2 24. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000162f9c70 25. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x00000000162fa55a 26. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc6653 27. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000000fccc4c3 28. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc3d92 29. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fcca080 30. ? @ 0x00007fbc6213eac3 31. ? @ 0x00007fbc621d0850 (version 25.3.6.10636.altinitytest (altinity build)) 2025.07.28 12:02:56.999890 [ 3976 ] {} test_13.rmt2 (7f9b740d-015c-470e-8cc6-8ba33be0dc63): auto DB::StorageReplicatedMergeTree::processQueueEntry(ReplicatedMergeTreeQueue::SelectedEntryPtr)::(anonymous class)::operator()(LogEntryPtr &) const: Code: 86. DB::HTTPException: Received error from remote server http://146b4357c08d:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Ftest%2F01165%2Ftest_13%2Frmt%2Freplicas%2F1&part=20250728_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.6.10636.altinitytest (altinity build)) '. (RECEIVED_ERROR_FROM_REMOTE_IO_SERVER), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.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 const&, int&&, String const&, unsigned long&&, String const&) @ 0x000000000feda8d9 4. /build/src/IO/HTTPCommon.cpp:104: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x000000000feda6e2 5. /build/src/IO/HTTPCommon.cpp:93: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x000000000feda537 6. /build/src/IO/ReadWriteBufferFromHTTP.cpp:277: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x000000001184a4c4 7. /build/src/IO/ReadWriteBufferFromHTTP.cpp:285: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x000000001184a615 8. /build/src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x000000001184ae59 9. /build/src/IO/ReadWriteBufferFromHTTP.cpp:472: void std::__function::__policy_invoker::__call_impl[abi:se190107]>(std::__function::__policy_storage const*) @ 0x000000001184cedd 10. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001184858b 11. /build/src/IO/ReadWriteBufferFromHTTP.cpp:465: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x000000001184bf0b 12. /build/src/IO/ReadBuffer.h:60: DB::ReadBuffer::next() @ 0x000000000a148c7b 13. /build/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) @ 0x0000000011849fb2 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]>&)>&, 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&) @ 0x0000000011841980 15. /build/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) @ 0x000000001621208e 16. /build/src/Storages/StorageReplicatedMergeTree.cpp:5228: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl[abi:se190107] const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000015f9a5fe 17. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000015ed8bfd 18. /build/src/Storages/StorageReplicatedMergeTree.cpp:2514: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x0000000015ec9aab 19. /build/src/Storages/StorageReplicatedMergeTree.cpp:2349: DB::StorageReplicatedMergeTree::executeLogEntry(DB::ReplicatedMergeTreeLogEntry&) @ 0x0000000015eba91b 20. /build/src/Storages/StorageReplicatedMergeTree.cpp:3876: bool std::__function::__policy_invoker&)>::__call_impl[abi:se190107])::$_1, bool (std::shared_ptr&)>>(std::__function::__policy_storage const*, std::shared_ptr&) @ 0x0000000015f9837e 21. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000165d6fc3 22. /build/src/Storages/StorageReplicatedMergeTree.cpp:3872: DB::StorageReplicatedMergeTree::processQueueEntry(std::shared_ptr) @ 0x0000000015efc18a 23. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001624c1b2 24. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000162f9c70 25. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x00000000162fa55a 26. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc6653 27. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000000fccc4c3 28. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc3d92 29. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fcca080 30. ? @ 0x00007fbc6213eac3 31. ? @ 0x00007fbc621d0850 (version 25.3.6.10636.altinitytest (altinity build)) 2025.07.28 12:02:57.009982 [ 17232 ] {6c127b0c-0e0f-4617-bc3e-0a6b36e0e185} executeQuery: Code: 452. DB::Exception: Setting allow_experimental_object_type should not be changed. (SETTING_CONSTRAINT_VIOLATION) (version 25.3.6.10636.altinitytest (altinity build)) (from [::1]:59268) (comment: 02789_object_type_invalid_num_of_rows.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. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x000000000c25bc4b 4. /build/src/Access/SettingsConstraints.cpp:343: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000138596e3 5. /build/src/Access/SettingsConstraints.cpp:300: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000013858faf 6. /build/src/Access/SettingsConstraints.cpp:194: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges const&, DB::SettingSource) const @ 0x00000000138591b3 7. /build/src/Interpreters/Context.cpp:2722: DB::Context::checkSettingsConstraints(DB::SettingsChanges const&, DB::SettingSource) @ 0x0000000014436509 8. /build/src/Interpreters/InterpreterSetQuery.cpp:28: DB::InterpreterSetQuery::execute() @ 0x00000000149e240a 9. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88dc9 10. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 11. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 12. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 13. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 14. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 16. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 17. ? @ 0x00007fbc6213eac3 18. ? @ 0x00007fbc621d0850 2025.07.28 12:02:57.078515 [ 17232 ] {} 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. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x000000000c25bc4b 4. /build/src/Access/SettingsConstraints.cpp:343: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000138596e3 5. /build/src/Access/SettingsConstraints.cpp:300: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000013858faf 6. /build/src/Access/SettingsConstraints.cpp:194: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges const&, DB::SettingSource) const @ 0x00000000138591b3 7. /build/src/Interpreters/Context.cpp:2722: DB::Context::checkSettingsConstraints(DB::SettingsChanges const&, DB::SettingSource) @ 0x0000000014436509 8. /build/src/Interpreters/InterpreterSetQuery.cpp:28: DB::InterpreterSetQuery::execute() @ 0x00000000149e240a 9. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88dc9 10. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 11. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 12. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 13. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 14. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 16. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 17. ? @ 0x00007fbc6213eac3 18. ? @ 0x00007fbc621d0850 2025.07.28 12:02:57.264025 [ 3971 ] {} test_13.rmt2 (7f9b740d-015c-470e-8cc6-8ba33be0dc63): auto DB::StorageReplicatedMergeTree::processQueueEntry(ReplicatedMergeTreeQueue::SelectedEntryPtr)::(anonymous class)::operator()(LogEntryPtr &) const: Code: 86. DB::HTTPException: Received error from remote server http://146b4357c08d:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Ftest%2F01165%2Ftest_13%2Frmt%2Freplicas%2F1&part=20250728_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.6.10636.altinitytest (altinity build)) '. (RECEIVED_ERROR_FROM_REMOTE_IO_SERVER), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.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 const&, int&&, String const&, unsigned long&&, String const&) @ 0x000000000feda8d9 4. /build/src/IO/HTTPCommon.cpp:104: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x000000000feda6e2 5. /build/src/IO/HTTPCommon.cpp:93: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x000000000feda537 6. /build/src/IO/ReadWriteBufferFromHTTP.cpp:277: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x000000001184a4c4 7. /build/src/IO/ReadWriteBufferFromHTTP.cpp:285: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x000000001184a615 8. /build/src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x000000001184ae59 9. /build/src/IO/ReadWriteBufferFromHTTP.cpp:472: void std::__function::__policy_invoker::__call_impl[abi:se190107]>(std::__function::__policy_storage const*) @ 0x000000001184cedd 10. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001184858b 11. /build/src/IO/ReadWriteBufferFromHTTP.cpp:465: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x000000001184bf0b 12. /build/src/IO/ReadBuffer.h:60: DB::ReadBuffer::next() @ 0x000000000a148c7b 13. /build/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) @ 0x0000000011849fb2 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]>&)>&, 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&) @ 0x0000000011841980 15. /build/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) @ 0x000000001621208e 16. /build/src/Storages/StorageReplicatedMergeTree.cpp:5228: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl[abi:se190107] const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000015f9a5fe 17. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000015ed8bfd 18. /build/src/Storages/StorageReplicatedMergeTree.cpp:2514: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x0000000015ec9aab 19. /build/src/Storages/StorageReplicatedMergeTree.cpp:2349: DB::StorageReplicatedMergeTree::executeLogEntry(DB::ReplicatedMergeTreeLogEntry&) @ 0x0000000015eba91b 20. /build/src/Storages/StorageReplicatedMergeTree.cpp:3876: bool std::__function::__policy_invoker&)>::__call_impl[abi:se190107])::$_1, bool (std::shared_ptr&)>>(std::__function::__policy_storage const*, std::shared_ptr&) @ 0x0000000015f9837e 21. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000165d6fc3 22. /build/src/Storages/StorageReplicatedMergeTree.cpp:3872: DB::StorageReplicatedMergeTree::processQueueEntry(std::shared_ptr) @ 0x0000000015efc18a 23. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001624c1b2 24. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000162f9c70 25. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x00000000162fa55a 26. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc6653 27. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000000fccc4c3 28. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc3d92 29. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fcca080 30. ? @ 0x00007fbc6213eac3 31. ? @ 0x00007fbc621d0850 (version 25.3.6.10636.altinitytest (altinity build)) 2025.07.28 12:02:57.579222 [ 3960 ] {} test_13.rmt2 (7f9b740d-015c-470e-8cc6-8ba33be0dc63): auto DB::StorageReplicatedMergeTree::processQueueEntry(ReplicatedMergeTreeQueue::SelectedEntryPtr)::(anonymous class)::operator()(LogEntryPtr &) const: Code: 86. DB::HTTPException: Received error from remote server http://146b4357c08d:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Ftest%2F01165%2Ftest_13%2Frmt%2Freplicas%2F1&part=20250728_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.6.10636.altinitytest (altinity build)) '. (RECEIVED_ERROR_FROM_REMOTE_IO_SERVER), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.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 const&, int&&, String const&, unsigned long&&, String const&) @ 0x000000000feda8d9 4. /build/src/IO/HTTPCommon.cpp:104: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x000000000feda6e2 5. /build/src/IO/HTTPCommon.cpp:93: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x000000000feda537 6. /build/src/IO/ReadWriteBufferFromHTTP.cpp:277: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x000000001184a4c4 7. /build/src/IO/ReadWriteBufferFromHTTP.cpp:285: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x000000001184a615 8. /build/src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x000000001184ae59 9. /build/src/IO/ReadWriteBufferFromHTTP.cpp:472: void std::__function::__policy_invoker::__call_impl[abi:se190107]>(std::__function::__policy_storage const*) @ 0x000000001184cedd 10. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001184858b 11. /build/src/IO/ReadWriteBufferFromHTTP.cpp:465: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x000000001184bf0b 12. /build/src/IO/ReadBuffer.h:60: DB::ReadBuffer::next() @ 0x000000000a148c7b 13. /build/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) @ 0x0000000011849fb2 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]>&)>&, 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&) @ 0x0000000011841980 15. /build/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) @ 0x000000001621208e 16. /build/src/Storages/StorageReplicatedMergeTree.cpp:5228: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl[abi:se190107] const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000015f9a5fe 17. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000015ed8bfd 18. /build/src/Storages/StorageReplicatedMergeTree.cpp:2514: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x0000000015ec9aab 19. /build/src/Storages/StorageReplicatedMergeTree.cpp:2349: DB::StorageReplicatedMergeTree::executeLogEntry(DB::ReplicatedMergeTreeLogEntry&) @ 0x0000000015eba91b 20. /build/src/Storages/StorageReplicatedMergeTree.cpp:3876: bool std::__function::__policy_invoker&)>::__call_impl[abi:se190107])::$_1, bool (std::shared_ptr&)>>(std::__function::__policy_storage const*, std::shared_ptr&) @ 0x0000000015f9837e 21. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000165d6fc3 22. /build/src/Storages/StorageReplicatedMergeTree.cpp:3872: DB::StorageReplicatedMergeTree::processQueueEntry(std::shared_ptr) @ 0x0000000015efc18a 23. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001624c1b2 24. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000162f9c70 25. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x00000000162fa55a 26. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc6653 27. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000000fccc4c3 28. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc3d92 29. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fcca080 30. ? @ 0x00007fbc6213eac3 31. ? @ 0x00007fbc621d0850 (version 25.3.6.10636.altinitytest (altinity build)) 2025.07.28 12:02:58.000880 [ 3965 ] {} test_13.rmt2 (7f9b740d-015c-470e-8cc6-8ba33be0dc63): auto DB::StorageReplicatedMergeTree::processQueueEntry(ReplicatedMergeTreeQueue::SelectedEntryPtr)::(anonymous class)::operator()(LogEntryPtr &) const: Code: 86. DB::HTTPException: Received error from remote server http://146b4357c08d:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Ftest%2F01165%2Ftest_13%2Frmt%2Freplicas%2F1&part=20250728_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.6.10636.altinitytest (altinity build)) '. (RECEIVED_ERROR_FROM_REMOTE_IO_SERVER), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.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 const&, int&&, String const&, unsigned long&&, String const&) @ 0x000000000feda8d9 4. /build/src/IO/HTTPCommon.cpp:104: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x000000000feda6e2 5. /build/src/IO/HTTPCommon.cpp:93: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x000000000feda537 6. /build/src/IO/ReadWriteBufferFromHTTP.cpp:277: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x000000001184a4c4 7. /build/src/IO/ReadWriteBufferFromHTTP.cpp:285: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x000000001184a615 8. /build/src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x000000001184ae59 9. /build/src/IO/ReadWriteBufferFromHTTP.cpp:472: void std::__function::__policy_invoker::__call_impl[abi:se190107]>(std::__function::__policy_storage const*) @ 0x000000001184cedd 10. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001184858b 11. /build/src/IO/ReadWriteBufferFromHTTP.cpp:465: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x000000001184bf0b 12. /build/src/IO/ReadBuffer.h:60: DB::ReadBuffer::next() @ 0x000000000a148c7b 13. /build/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) @ 0x0000000011849fb2 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]>&)>&, 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&) @ 0x0000000011841980 15. /build/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) @ 0x000000001621208e 16. /build/src/Storages/StorageReplicatedMergeTree.cpp:5228: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl[abi:se190107] const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000015f9a5fe 17. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000015ed8bfd 18. /build/src/Storages/StorageReplicatedMergeTree.cpp:2514: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x0000000015ec9aab 19. /build/src/Storages/StorageReplicatedMergeTree.cpp:2349: DB::StorageReplicatedMergeTree::executeLogEntry(DB::ReplicatedMergeTreeLogEntry&) @ 0x0000000015eba91b 20. /build/src/Storages/StorageReplicatedMergeTree.cpp:3876: bool std::__function::__policy_invoker&)>::__call_impl[abi:se190107])::$_1, bool (std::shared_ptr&)>>(std::__function::__policy_storage const*, std::shared_ptr&) @ 0x0000000015f9837e 21. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000165d6fc3 22. /build/src/Storages/StorageReplicatedMergeTree.cpp:3872: DB::StorageReplicatedMergeTree::processQueueEntry(std::shared_ptr) @ 0x0000000015efc18a 23. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001624c1b2 24. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000162f9c70 25. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x00000000162fa55a 26. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc6653 27. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000000fccc4c3 28. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc3d92 29. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fcca080 30. ? @ 0x00007fbc6213eac3 31. ? @ 0x00007fbc621d0850 (version 25.3.6.10636.altinitytest (altinity build)) 2025.07.28 12:02:58.347492 [ 3977 ] {} test_13.rmt2 (7f9b740d-015c-470e-8cc6-8ba33be0dc63): auto DB::StorageReplicatedMergeTree::processQueueEntry(ReplicatedMergeTreeQueue::SelectedEntryPtr)::(anonymous class)::operator()(LogEntryPtr &) const: Code: 86. DB::HTTPException: Received error from remote server http://146b4357c08d:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Ftest%2F01165%2Ftest_13%2Frmt%2Freplicas%2F1&part=20250728_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.6.10636.altinitytest (altinity build)) '. (RECEIVED_ERROR_FROM_REMOTE_IO_SERVER), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.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 const&, int&&, String const&, unsigned long&&, String const&) @ 0x000000000feda8d9 4. /build/src/IO/HTTPCommon.cpp:104: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x000000000feda6e2 5. /build/src/IO/HTTPCommon.cpp:93: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x000000000feda537 6. /build/src/IO/ReadWriteBufferFromHTTP.cpp:277: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x000000001184a4c4 7. /build/src/IO/ReadWriteBufferFromHTTP.cpp:285: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x000000001184a615 8. /build/src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x000000001184ae59 9. /build/src/IO/ReadWriteBufferFromHTTP.cpp:472: void std::__function::__policy_invoker::__call_impl[abi:se190107]>(std::__function::__policy_storage const*) @ 0x000000001184cedd 10. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001184858b 11. /build/src/IO/ReadWriteBufferFromHTTP.cpp:465: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x000000001184bf0b 12. /build/src/IO/ReadBuffer.h:60: DB::ReadBuffer::next() @ 0x000000000a148c7b 13. /build/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) @ 0x0000000011849fb2 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]>&)>&, 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&) @ 0x0000000011841980 15. /build/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) @ 0x000000001621208e 16. /build/src/Storages/StorageReplicatedMergeTree.cpp:5228: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl[abi:se190107] const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000015f9a5fe 17. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000015ed8bfd 18. /build/src/Storages/StorageReplicatedMergeTree.cpp:2514: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x0000000015ec9aab 19. /build/src/Storages/StorageReplicatedMergeTree.cpp:2349: DB::StorageReplicatedMergeTree::executeLogEntry(DB::ReplicatedMergeTreeLogEntry&) @ 0x0000000015eba91b 20. /build/src/Storages/StorageReplicatedMergeTree.cpp:3876: bool std::__function::__policy_invoker&)>::__call_impl[abi:se190107])::$_1, bool (std::shared_ptr&)>>(std::__function::__policy_storage const*, std::shared_ptr&) @ 0x0000000015f9837e 21. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000165d6fc3 22. /build/src/Storages/StorageReplicatedMergeTree.cpp:3872: DB::StorageReplicatedMergeTree::processQueueEntry(std::shared_ptr) @ 0x0000000015efc18a 23. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001624c1b2 24. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000162f9c70 25. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x00000000162fa55a 26. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc6653 27. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000000fccc4c3 28. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc3d92 29. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fcca080 30. ? @ 0x00007fbc6213eac3 31. ? @ 0x00007fbc621d0850 (version 25.3.6.10636.altinitytest (altinity build)) 2025.07.28 12:02:58.592554 [ 17611 ] {} 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. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x000000000c25bc4b 4. /build/src/Access/SettingsConstraints.cpp:343: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000138596e3 5. /build/src/Access/SettingsConstraints.cpp:300: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000013858faf 6. /build/src/Access/SettingsConstraints.cpp:209: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x00000000138592b8 7. /build/src/Interpreters/Context.cpp:2690: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000014436134 8. /build/src/Interpreters/Context.cpp:2729: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x000000001443662b 9. /build/src/Server/TCPHandler.cpp:2158: DB::TCPHandler::processQuery(std::optional&) @ 0x00000000168f61df 10. /build/src/Server/TCPHandler.cpp:918: DB::TCPHandler::receivePacketsExpectQuery(std::optional&) @ 0x00000000168ef965 11. /build/src/Server/TCPHandler.cpp:491: DB::TCPHandler::runImpl() @ 0x00000000168e5eb4 12. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 13. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 14. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 16. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 17. ? @ 0x00007fbc6213eac3 18. ? @ 0x00007fbc621d0850 2025.07.28 12:02:58.599814 [ 17611 ] {} 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. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000000a074fcb 4. /build/src/Server/TCPHandler.cpp:897: DB::TCPHandler::receivePacketsExpectQuery(std::optional&) @ 0x00000000168efa89 5. /build/src/Server/TCPHandler.cpp:491: DB::TCPHandler::runImpl() @ 0x00000000168e5eb4 6. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 7. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 8. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 9. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 10. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 11. ? @ 0x00007fbc6213eac3 12. ? @ 0x00007fbc621d0850 2025.07.28 12:02:58.846217 [ 3961 ] {} test_13.rmt2 (7f9b740d-015c-470e-8cc6-8ba33be0dc63): auto DB::StorageReplicatedMergeTree::processQueueEntry(ReplicatedMergeTreeQueue::SelectedEntryPtr)::(anonymous class)::operator()(LogEntryPtr &) const: Code: 86. DB::HTTPException: Received error from remote server http://146b4357c08d:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Ftest%2F01165%2Ftest_13%2Frmt%2Freplicas%2F1&part=20250728_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.6.10636.altinitytest (altinity build)) '. (RECEIVED_ERROR_FROM_REMOTE_IO_SERVER), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.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 const&, int&&, String const&, unsigned long&&, String const&) @ 0x000000000feda8d9 4. /build/src/IO/HTTPCommon.cpp:104: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x000000000feda6e2 5. /build/src/IO/HTTPCommon.cpp:93: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x000000000feda537 6. /build/src/IO/ReadWriteBufferFromHTTP.cpp:277: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x000000001184a4c4 7. /build/src/IO/ReadWriteBufferFromHTTP.cpp:285: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x000000001184a615 8. /build/src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x000000001184ae59 9. /build/src/IO/ReadWriteBufferFromHTTP.cpp:472: void std::__function::__policy_invoker::__call_impl[abi:se190107]>(std::__function::__policy_storage const*) @ 0x000000001184cedd 10. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001184858b 11. /build/src/IO/ReadWriteBufferFromHTTP.cpp:465: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x000000001184bf0b 12. /build/src/IO/ReadBuffer.h:60: DB::ReadBuffer::next() @ 0x000000000a148c7b 13. /build/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) @ 0x0000000011849fb2 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]>&)>&, 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&) @ 0x0000000011841980 15. /build/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) @ 0x000000001621208e 16. /build/src/Storages/StorageReplicatedMergeTree.cpp:5228: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl[abi:se190107] const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000015f9a5fe 17. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000015ed8bfd 18. /build/src/Storages/StorageReplicatedMergeTree.cpp:2514: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x0000000015ec9aab 19. /build/src/Storages/StorageReplicatedMergeTree.cpp:2349: DB::StorageReplicatedMergeTree::executeLogEntry(DB::ReplicatedMergeTreeLogEntry&) @ 0x0000000015eba91b 20. /build/src/Storages/StorageReplicatedMergeTree.cpp:3876: bool std::__function::__policy_invoker&)>::__call_impl[abi:se190107])::$_1, bool (std::shared_ptr&)>>(std::__function::__policy_storage const*, std::shared_ptr&) @ 0x0000000015f9837e 21. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000165d6fc3 22. /build/src/Storages/StorageReplicatedMergeTree.cpp:3872: DB::StorageReplicatedMergeTree::processQueueEntry(std::shared_ptr) @ 0x0000000015efc18a 23. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001624c1b2 24. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000162f9c70 25. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x00000000162fa55a 26. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc6653 27. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000000fccc4c3 28. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc3d92 29. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fcca080 30. ? @ 0x00007fbc6213eac3 31. ? @ 0x00007fbc621d0850 (version 25.3.6.10636.altinitytest (altinity build)) 2025.07.28 12:02:59.558348 [ 3971 ] {} test_13.rmt2 (7f9b740d-015c-470e-8cc6-8ba33be0dc63): auto DB::StorageReplicatedMergeTree::processQueueEntry(ReplicatedMergeTreeQueue::SelectedEntryPtr)::(anonymous class)::operator()(LogEntryPtr &) const: Code: 86. DB::HTTPException: Received error from remote server http://146b4357c08d:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Ftest%2F01165%2Ftest_13%2Frmt%2Freplicas%2F1&part=20250728_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.6.10636.altinitytest (altinity build)) '. (RECEIVED_ERROR_FROM_REMOTE_IO_SERVER), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.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 const&, int&&, String const&, unsigned long&&, String const&) @ 0x000000000feda8d9 4. /build/src/IO/HTTPCommon.cpp:104: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x000000000feda6e2 5. /build/src/IO/HTTPCommon.cpp:93: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x000000000feda537 6. /build/src/IO/ReadWriteBufferFromHTTP.cpp:277: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x000000001184a4c4 7. /build/src/IO/ReadWriteBufferFromHTTP.cpp:285: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x000000001184a615 8. /build/src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x000000001184ae59 9. /build/src/IO/ReadWriteBufferFromHTTP.cpp:472: void std::__function::__policy_invoker::__call_impl[abi:se190107]>(std::__function::__policy_storage const*) @ 0x000000001184cedd 10. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001184858b 11. /build/src/IO/ReadWriteBufferFromHTTP.cpp:465: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x000000001184bf0b 12. /build/src/IO/ReadBuffer.h:60: DB::ReadBuffer::next() @ 0x000000000a148c7b 13. /build/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) @ 0x0000000011849fb2 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]>&)>&, 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&) @ 0x0000000011841980 15. /build/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) @ 0x000000001621208e 16. /build/src/Storages/StorageReplicatedMergeTree.cpp:5228: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl[abi:se190107] const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000015f9a5fe 17. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000015ed8bfd 18. /build/src/Storages/StorageReplicatedMergeTree.cpp:2514: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x0000000015ec9aab 19. /build/src/Storages/StorageReplicatedMergeTree.cpp:2349: DB::StorageReplicatedMergeTree::executeLogEntry(DB::ReplicatedMergeTreeLogEntry&) @ 0x0000000015eba91b 20. /build/src/Storages/StorageReplicatedMergeTree.cpp:3876: bool std::__function::__policy_invoker&)>::__call_impl[abi:se190107])::$_1, bool (std::shared_ptr&)>>(std::__function::__policy_storage const*, std::shared_ptr&) @ 0x0000000015f9837e 21. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000165d6fc3 22. /build/src/Storages/StorageReplicatedMergeTree.cpp:3872: DB::StorageReplicatedMergeTree::processQueueEntry(std::shared_ptr) @ 0x0000000015efc18a 23. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001624c1b2 24. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000162f9c70 25. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x00000000162fa55a 26. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc6653 27. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000000fccc4c3 28. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc3d92 29. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fcca080 30. ? @ 0x00007fbc6213eac3 31. ? @ 0x00007fbc621d0850 (version 25.3.6.10636.altinitytest (altinity build)) 2025.07.28 12:02:59.720554 [ 62075 ] {7896a548-8a31-4e1d-9ffb-11ed024bd2e1} executeQuery: Code: 57. DB::Exception: Table test_9.t already exists. (TABLE_ALREADY_EXISTS) (version 25.3.6.10636.altinitytest (altinity build)) (from [::1]:59270) (comment: 00977_join_use_nulls_denny_crane.sql) (query 13, line 18) (in query: CREATE TABLE t (`a` Int64, `b` Int64, `c` Nullable(String)) ENGINE = MergeTree ORDER BY tuple() SETTINGS index_granularity = 8401, 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 = 84746565, compact_parts_max_bytes_to_buffer = 295973379, compact_parts_max_granules_to_buffer = 256, compact_parts_merge_max_bytes_to_prefetch_part = 15501585, merge_max_block_size = 17322, old_parts_lifetime = 108., prefer_fetch_merged_part_size_threshold = 10561718420, vertical_merge_algorithm_min_rows_to_activate = 1, vertical_merge_algorithm_min_columns_to_activate = 100, min_merge_bytes_to_use_direct_io = 10607680979, index_granularity_bytes = 25472907, 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 = 54910, primary_key_compress_block_size = 93582, 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. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000a06a8eb 4. /build/src/Interpreters/InterpreterCreateQuery.cpp:1824: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x0000000014901d53 5. /build/src/Interpreters/InterpreterCreateQuery.cpp:1743: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000148f9aa9 6. /build/src/Interpreters/InterpreterCreateQuery.cpp:2352: DB::InterpreterCreateQuery::execute() @ 0x0000000014905a41 7. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88dc9 8. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 9. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 10. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 11. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 12. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 13. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 14. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 15. ? @ 0x00007fbc6213eac3 16. ? @ 0x00007fbc621d0850 2025.07.28 12:02:59.735288 [ 62075 ] {} 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. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000a06a8eb 4. /build/src/Interpreters/InterpreterCreateQuery.cpp:1824: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x0000000014901d53 5. /build/src/Interpreters/InterpreterCreateQuery.cpp:1743: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000148f9aa9 6. /build/src/Interpreters/InterpreterCreateQuery.cpp:2352: DB::InterpreterCreateQuery::execute() @ 0x0000000014905a41 7. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88dc9 8. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 9. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 10. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 11. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 12. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 13. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 14. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 15. ? @ 0x00007fbc6213eac3 16. ? @ 0x00007fbc621d0850 2025.07.28 12:02:59.762633 [ 5951 ] {49bb4b02-3cec-46e6-9469-fb845f751289} executeQuery: Code: 25. DB::Exception: Invalid escape sequence at the end of LIKE pattern '\': In scope SELECT '\\' LIKE '\\'. (CANNOT_PARSE_ESCAPE_SEQUENCE) (version 25.3.6.10636.altinitytest (altinity build)) (from [::1]:59280) (comment: 01847_bad_like.sql) (query 21, line 25) (in query: SELECT '\\' LIKE '\\';), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x000000000c25bc4b 4. /build/src/Common/likePatternToRegexp.cpp:61: DB::likePatternToRegexp(std::basic_string_view>) @ 0x000000000fc61be8 5. /build/src/Functions/Regexps.h:58: OptimizedRegularExpression DB::Regexps::createRegexp(String const&) @ 0x000000000cf64ca1 6. /build/src/Functions/Regexps.h:82: std::shared_ptr DB::Regexps::LocalCacheTable::getOrSet(String const&) @ 0x000000000cf648f3 7. /build/src/Functions/MatchImpl.h:515: DB::MatchImpl::vectorVector(DB::PODArray, 63ul, 64ul> const&, DB::PODArray, 63ul, 64ul> const&, DB::PODArray, 63ul, 64ul> const&, DB::PODArray, 63ul, 64ul> const&, COW::immutable_ptr const&, DB::PODArray, 63ul, 64ul>&, DB::ColumnVector*, unsigned long) @ 0x000000000cf61d32 8. /build/src/Functions/FunctionsStringSearch.h:316: DB::FunctionsStringSearch, (DB::ExecutionErrorPolicy)1, (DB::HaystackNeedleOrderIsConfigurable)0>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000cf601c5 9. /build/src/Functions/IFunction.h:437: DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000a069f2a 10. /build/src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000012d9965a 11. /build/src/Functions/IFunction.cpp:351: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d93b02 12. /build/src/Functions/IFunction.cpp:177: DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d93698 13. /build/src/Functions/IFunction.cpp:343: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d93aad 14. /build/src/Functions/IFunction.cpp:420: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d95059 15. /build/src/Functions/IFunction.cpp:498: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d95c72 16. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3567: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000014034494 17. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3838: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000014019a9e 18. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3980: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000014018e31 19. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:4304: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000014042fa7 20. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5605: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000014013749 21. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000140127f9 22. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000014011fce 23. /build/src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000001406ce8a 24. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000014973b42 25. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000001497268d 26. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000014974d24 27. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001492924b 28. /build/src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88641 29. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 30. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 31. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 2025.07.28 12:02:59.775835 [ 5951 ] {} TCPHandler: Code: 25. DB::Exception: Invalid escape sequence at the end of LIKE pattern '\': In scope SELECT '\\' LIKE '\\'. (CANNOT_PARSE_ESCAPE_SEQUENCE), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x000000000c25bc4b 4. /build/src/Common/likePatternToRegexp.cpp:61: DB::likePatternToRegexp(std::basic_string_view>) @ 0x000000000fc61be8 5. /build/src/Functions/Regexps.h:58: OptimizedRegularExpression DB::Regexps::createRegexp(String const&) @ 0x000000000cf64ca1 6. /build/src/Functions/Regexps.h:82: std::shared_ptr DB::Regexps::LocalCacheTable::getOrSet(String const&) @ 0x000000000cf648f3 7. /build/src/Functions/MatchImpl.h:515: DB::MatchImpl::vectorVector(DB::PODArray, 63ul, 64ul> const&, DB::PODArray, 63ul, 64ul> const&, DB::PODArray, 63ul, 64ul> const&, DB::PODArray, 63ul, 64ul> const&, COW::immutable_ptr const&, DB::PODArray, 63ul, 64ul>&, DB::ColumnVector*, unsigned long) @ 0x000000000cf61d32 8. /build/src/Functions/FunctionsStringSearch.h:316: DB::FunctionsStringSearch, (DB::ExecutionErrorPolicy)1, (DB::HaystackNeedleOrderIsConfigurable)0>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000cf601c5 9. /build/src/Functions/IFunction.h:437: DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000a069f2a 10. /build/src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000012d9965a 11. /build/src/Functions/IFunction.cpp:351: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d93b02 12. /build/src/Functions/IFunction.cpp:177: DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d93698 13. /build/src/Functions/IFunction.cpp:343: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d93aad 14. /build/src/Functions/IFunction.cpp:420: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d95059 15. /build/src/Functions/IFunction.cpp:498: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d95c72 16. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3567: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000014034494 17. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3838: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000014019a9e 18. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3980: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000014018e31 19. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:4304: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000014042fa7 20. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5605: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000014013749 21. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000140127f9 22. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000014011fce 23. /build/src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000001406ce8a 24. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000014973b42 25. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000001497268d 26. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000014974d24 27. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001492924b 28. /build/src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88641 29. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 30. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 31. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 2025.07.28 12:02:59.906872 [ 4900 ] {} 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. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x000000000c25bc4b 4. /build/src/Access/SettingsConstraints.cpp:343: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000138596e3 5. /build/src/Access/SettingsConstraints.cpp:300: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000013858faf 6. /build/src/Access/SettingsConstraints.cpp:209: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x00000000138592b8 7. /build/src/Interpreters/Context.cpp:2690: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000014436134 8. /build/src/Interpreters/Context.cpp:2729: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x000000001443662b 9. /build/src/Server/TCPHandler.cpp:2158: DB::TCPHandler::processQuery(std::optional&) @ 0x00000000168f61df 10. /build/src/Server/TCPHandler.cpp:918: DB::TCPHandler::receivePacketsExpectQuery(std::optional&) @ 0x00000000168ef965 11. /build/src/Server/TCPHandler.cpp:491: DB::TCPHandler::runImpl() @ 0x00000000168e5eb4 12. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 13. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 14. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 16. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 17. ? @ 0x00007fbc6213eac3 18. ? @ 0x00007fbc621d0850 2025.07.28 12:02:59.920894 [ 4900 ] {} 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. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000000a074fcb 4. /build/src/Server/TCPHandler.cpp:897: DB::TCPHandler::receivePacketsExpectQuery(std::optional&) @ 0x00000000168efa89 5. /build/src/Server/TCPHandler.cpp:491: DB::TCPHandler::runImpl() @ 0x00000000168e5eb4 6. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 7. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 8. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 9. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 10. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 11. ? @ 0x00007fbc6213eac3 12. ? @ 0x00007fbc621d0850 2025.07.28 12:03:00.095395 [ 62114 ] {16aecd24-10da-4fa7-8c21-7eba1b36eba0} executeQuery: Code: 43. DB::Exception: addMilliseconds cannot be used with Date: In scope SELECT toDate('2001-09-29') + toIntervalMillisecond(12345) AS x, toTypeName(x). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.6.10636.altinitytest (altinity build)) (from [::1]:59358) (comment: 01099_operators_date_and_timestamp.sql) (query 16, line 19) (in query: select (date '2001-09-29' + interval 12345 millisecond) x, toTypeName(x);), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000a06a8eb 4. /build/src/Functions/FunctionDateOrDateTimeAddInterval.h:696: std::shared_ptr DB::FunctionDateOrDateTimeAddInterval::resolveReturnType(std::vector> const&) const @ 0x000000000aa2e256 5. /build/src/Functions/IFunction.cpp:645: DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x0000000012d96b0c 6. /build/src/Functions/IFunction.cpp:577: DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x0000000012d9669c 7. /build/src/Functions/IFunction.cpp:606: DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x0000000012d96edc 8. /build/src/Functions/FunctionBinaryArithmetic.h:1742: DB::FunctionBinaryArithmetic::getReturnTypeImplStatic(std::vector, std::allocator>> const&, std::shared_ptr) @ 0x000000000e04d131 9. /build/src/Functions/IFunction.h:369: DB::IFunctionOverloadResolver::getReturnTypeImpl(std::vector> const&) const @ 0x000000000a6646de 10. /build/src/Functions/IFunction.cpp:645: DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x0000000012d96b0c 11. /build/src/Functions/IFunction.cpp:577: DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x0000000012d9669c 12. /build/src/Functions/IFunction.cpp:606: DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x0000000012d96edc 13. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3544: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000014033cc9 14. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3838: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000014019a9e 15. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3980: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000014018e31 16. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:4304: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000014042fa7 17. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5605: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000014013749 18. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000140127f9 19. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000014011fce 20. /build/src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000001406ce8a 21. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000014973b42 22. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000001497268d 23. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000014974d24 24. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001492924b 25. /build/src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88641 26. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 27. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 28. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 29. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 30. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 31. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 2025.07.28 12:03:00.103156 [ 4900 ] {} 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. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x000000000c25bc4b 4. /build/src/Access/SettingsConstraints.cpp:343: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000138596e3 5. /build/src/Access/SettingsConstraints.cpp:300: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000013858faf 6. /build/src/Access/SettingsConstraints.cpp:209: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x00000000138592b8 7. /build/src/Interpreters/Context.cpp:2690: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000014436134 8. /build/src/Interpreters/Context.cpp:2729: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x000000001443662b 9. /build/src/Server/TCPHandler.cpp:2158: DB::TCPHandler::processQuery(std::optional&) @ 0x00000000168f61df 10. /build/src/Server/TCPHandler.cpp:918: DB::TCPHandler::receivePacketsExpectQuery(std::optional&) @ 0x00000000168ef965 11. /build/src/Server/TCPHandler.cpp:491: DB::TCPHandler::runImpl() @ 0x00000000168e5eb4 12. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 13. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 14. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 16. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 17. ? @ 0x00007fbc6213eac3 18. ? @ 0x00007fbc621d0850 2025.07.28 12:03:00.108014 [ 4900 ] {} 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. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000000a074fcb 4. /build/src/Server/TCPHandler.cpp:897: DB::TCPHandler::receivePacketsExpectQuery(std::optional&) @ 0x00000000168efa89 5. /build/src/Server/TCPHandler.cpp:491: DB::TCPHandler::runImpl() @ 0x00000000168e5eb4 6. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 7. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 8. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 9. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 10. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 11. ? @ 0x00007fbc6213eac3 12. ? @ 0x00007fbc621d0850 2025.07.28 12:03:00.116504 [ 62114 ] {} TCPHandler: Code: 43. DB::Exception: addMilliseconds cannot be used with Date: In scope SELECT toDate('2001-09-29') + toIntervalMillisecond(12345) AS x, toTypeName(x). (ILLEGAL_TYPE_OF_ARGUMENT), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000a06a8eb 4. /build/src/Functions/FunctionDateOrDateTimeAddInterval.h:696: std::shared_ptr DB::FunctionDateOrDateTimeAddInterval::resolveReturnType(std::vector> const&) const @ 0x000000000aa2e256 5. /build/src/Functions/IFunction.cpp:645: DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x0000000012d96b0c 6. /build/src/Functions/IFunction.cpp:577: DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x0000000012d9669c 7. /build/src/Functions/IFunction.cpp:606: DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x0000000012d96edc 8. /build/src/Functions/FunctionBinaryArithmetic.h:1742: DB::FunctionBinaryArithmetic::getReturnTypeImplStatic(std::vector, std::allocator>> const&, std::shared_ptr) @ 0x000000000e04d131 9. /build/src/Functions/IFunction.h:369: DB::IFunctionOverloadResolver::getReturnTypeImpl(std::vector> const&) const @ 0x000000000a6646de 10. /build/src/Functions/IFunction.cpp:645: DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x0000000012d96b0c 11. /build/src/Functions/IFunction.cpp:577: DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x0000000012d9669c 12. /build/src/Functions/IFunction.cpp:606: DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x0000000012d96edc 13. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3544: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000014033cc9 14. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3838: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000014019a9e 15. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3980: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000014018e31 16. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:4304: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000014042fa7 17. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5605: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000014013749 18. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000140127f9 19. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000014011fce 20. /build/src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000001406ce8a 21. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000014973b42 22. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000001497268d 23. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000014974d24 24. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001492924b 25. /build/src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88641 26. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 27. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 28. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 29. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 30. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 31. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 2025.07.28 12:03:00.172948 [ 3974 ] {} test_13.rmt2 (7f9b740d-015c-470e-8cc6-8ba33be0dc63): auto DB::StorageReplicatedMergeTree::processQueueEntry(ReplicatedMergeTreeQueue::SelectedEntryPtr)::(anonymous class)::operator()(LogEntryPtr &) const: Code: 86. DB::HTTPException: Received error from remote server http://146b4357c08d:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Ftest%2F01165%2Ftest_13%2Frmt%2Freplicas%2F1&part=20250728_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.6.10636.altinitytest (altinity build)) '. (RECEIVED_ERROR_FROM_REMOTE_IO_SERVER), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.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 const&, int&&, String const&, unsigned long&&, String const&) @ 0x000000000feda8d9 4. /build/src/IO/HTTPCommon.cpp:104: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x000000000feda6e2 5. /build/src/IO/HTTPCommon.cpp:93: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x000000000feda537 6. /build/src/IO/ReadWriteBufferFromHTTP.cpp:277: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x000000001184a4c4 7. /build/src/IO/ReadWriteBufferFromHTTP.cpp:285: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x000000001184a615 8. /build/src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x000000001184ae59 9. /build/src/IO/ReadWriteBufferFromHTTP.cpp:472: void std::__function::__policy_invoker::__call_impl[abi:se190107]>(std::__function::__policy_storage const*) @ 0x000000001184cedd 10. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001184858b 11. /build/src/IO/ReadWriteBufferFromHTTP.cpp:465: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x000000001184bf0b 12. /build/src/IO/ReadBuffer.h:60: DB::ReadBuffer::next() @ 0x000000000a148c7b 13. /build/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) @ 0x0000000011849fb2 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]>&)>&, 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&) @ 0x0000000011841980 15. /build/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) @ 0x000000001621208e 16. /build/src/Storages/StorageReplicatedMergeTree.cpp:5228: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl[abi:se190107] const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000015f9a5fe 17. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000015ed8bfd 18. /build/src/Storages/StorageReplicatedMergeTree.cpp:2514: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x0000000015ec9aab 19. /build/src/Storages/StorageReplicatedMergeTree.cpp:2349: DB::StorageReplicatedMergeTree::executeLogEntry(DB::ReplicatedMergeTreeLogEntry&) @ 0x0000000015eba91b 20. /build/src/Storages/StorageReplicatedMergeTree.cpp:3876: bool std::__function::__policy_invoker&)>::__call_impl[abi:se190107])::$_1, bool (std::shared_ptr&)>>(std::__function::__policy_storage const*, std::shared_ptr&) @ 0x0000000015f9837e 21. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000165d6fc3 22. /build/src/Storages/StorageReplicatedMergeTree.cpp:3872: DB::StorageReplicatedMergeTree::processQueueEntry(std::shared_ptr) @ 0x0000000015efc18a 23. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001624c1b2 24. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000162f9c70 25. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x00000000162fa55a 26. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc6653 27. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000000fccc4c3 28. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc3d92 29. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fcca080 30. ? @ 0x00007fbc6213eac3 31. ? @ 0x00007fbc621d0850 (version 25.3.6.10636.altinitytest (altinity build)) 2025.07.28 12:03:00.253012 [ 4900 ] {8d140e3c-9e22-48c9-861f-6d3187955f24} executeQuery: Code: 60. DB::Exception: Unknown table expression identifier 't_json_inference' in scope SELECT * FROM t_json_inference. (UNKNOWN_TABLE) (version 25.3.6.10636.altinitytest (altinity build)) (from [::1]:59458) (comment: 01825_type_json_schema_inference.sh) (query 1, line 1) (in query: SELECT * FROM t_json_inference FORMAT JSONEachRow), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x000000000a6a1e2b 4. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:4372: DB::QueryAnalyzer::initializeQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000001404440b 5. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5594: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000140135fb 6. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000140127f9 7. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000014011fce 8. /build/src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000001406ce8a 9. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000014973b42 10. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000001497268d 11. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000014974d24 12. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001492924b 13. /build/src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88641 14. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 15. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 16. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 17. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 18. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 19. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 20. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 21. ? @ 0x00007fbc6213eac3 22. ? @ 0x00007fbc621d0850 2025.07.28 12:03:00.275404 [ 4900 ] {} TCPHandler: Code: 60. DB::Exception: Unknown table expression identifier 't_json_inference' in scope SELECT * FROM t_json_inference. (UNKNOWN_TABLE), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x000000000a6a1e2b 4. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:4372: DB::QueryAnalyzer::initializeQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000001404440b 5. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5594: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000140135fb 6. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000140127f9 7. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000014011fce 8. /build/src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000001406ce8a 9. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000014973b42 10. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000001497268d 11. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000014974d24 12. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001492924b 13. /build/src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88641 14. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 15. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 16. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 17. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 18. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 19. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 20. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 21. ? @ 0x00007fbc6213eac3 22. ? @ 0x00007fbc621d0850 2025.07.28 12:03:00.364759 [ 62114 ] {96bd68f8-d85d-4ff4-9aa3-9180f2885509} executeQuery: Code: 43. DB::Exception: addMicroseconds cannot be used with Date: In scope SELECT toDate('2001-09-29') + toIntervalMicrosecond(12345) AS x, toTypeName(x). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.6.10636.altinitytest (altinity build)) (from [::1]:59358) (comment: 01099_operators_date_and_timestamp.sql) (query 17, line 20) (in query: select (date '2001-09-29' + interval 12345 microsecond) x, toTypeName(x);), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000a06a8eb 4. /build/src/Functions/FunctionDateOrDateTimeAddInterval.h:696: std::shared_ptr DB::FunctionDateOrDateTimeAddInterval::resolveReturnType(std::vector> const&) const @ 0x000000000aa1bdf6 5. /build/src/Functions/IFunction.cpp:645: DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x0000000012d96b0c 6. /build/src/Functions/IFunction.cpp:577: DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x0000000012d9669c 7. /build/src/Functions/IFunction.cpp:606: DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x0000000012d96edc 8. /build/src/Functions/FunctionBinaryArithmetic.h:1742: DB::FunctionBinaryArithmetic::getReturnTypeImplStatic(std::vector, std::allocator>> const&, std::shared_ptr) @ 0x000000000e04d131 9. /build/src/Functions/IFunction.h:369: DB::IFunctionOverloadResolver::getReturnTypeImpl(std::vector> const&) const @ 0x000000000a6646de 10. /build/src/Functions/IFunction.cpp:645: DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x0000000012d96b0c 11. /build/src/Functions/IFunction.cpp:577: DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x0000000012d9669c 12. /build/src/Functions/IFunction.cpp:606: DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x0000000012d96edc 13. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3544: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000014033cc9 14. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3838: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000014019a9e 15. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3980: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000014018e31 16. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:4304: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000014042fa7 17. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5605: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000014013749 18. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000140127f9 19. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000014011fce 20. /build/src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000001406ce8a 21. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000014973b42 22. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000001497268d 23. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000014974d24 24. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001492924b 25. /build/src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88641 26. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 27. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 28. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 29. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 30. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 31. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 2025.07.28 12:03:00.386977 [ 62114 ] {} TCPHandler: Code: 43. DB::Exception: addMicroseconds cannot be used with Date: In scope SELECT toDate('2001-09-29') + toIntervalMicrosecond(12345) AS x, toTypeName(x). (ILLEGAL_TYPE_OF_ARGUMENT), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000a06a8eb 4. /build/src/Functions/FunctionDateOrDateTimeAddInterval.h:696: std::shared_ptr DB::FunctionDateOrDateTimeAddInterval::resolveReturnType(std::vector> const&) const @ 0x000000000aa1bdf6 5. /build/src/Functions/IFunction.cpp:645: DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x0000000012d96b0c 6. /build/src/Functions/IFunction.cpp:577: DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x0000000012d9669c 7. /build/src/Functions/IFunction.cpp:606: DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x0000000012d96edc 8. /build/src/Functions/FunctionBinaryArithmetic.h:1742: DB::FunctionBinaryArithmetic::getReturnTypeImplStatic(std::vector, std::allocator>> const&, std::shared_ptr) @ 0x000000000e04d131 9. /build/src/Functions/IFunction.h:369: DB::IFunctionOverloadResolver::getReturnTypeImpl(std::vector> const&) const @ 0x000000000a6646de 10. /build/src/Functions/IFunction.cpp:645: DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x0000000012d96b0c 11. /build/src/Functions/IFunction.cpp:577: DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x0000000012d9669c 12. /build/src/Functions/IFunction.cpp:606: DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x0000000012d96edc 13. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3544: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000014033cc9 14. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3838: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000014019a9e 15. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3980: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000014018e31 16. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:4304: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000014042fa7 17. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5605: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000014013749 18. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000140127f9 19. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000014011fce 20. /build/src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000001406ce8a 21. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000014973b42 22. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000001497268d 23. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000014974d24 24. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001492924b 25. /build/src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88641 26. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 27. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 28. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 29. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 30. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 31. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 2025.07.28 12:03:00.477765 [ 62114 ] {4be1ba7e-1b70-49e6-a2bf-1258758718da} executeQuery: Code: 43. DB::Exception: addNanoseconds cannot be used with Date: In scope SELECT toDate('2001-09-29') + toIntervalNanosecond(12345) AS x, toTypeName(x). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.6.10636.altinitytest (altinity build)) (from [::1]:59358) (comment: 01099_operators_date_and_timestamp.sql) (query 18, line 21) (in query: select (date '2001-09-29' + interval 12345 nanosecond) x, toTypeName(x);), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000a06a8eb 4. /build/src/Functions/FunctionDateOrDateTimeAddInterval.h:696: std::shared_ptr DB::FunctionDateOrDateTimeAddInterval::resolveReturnType(std::vector> const&) const @ 0x000000000aa69096 5. /build/src/Functions/IFunction.cpp:645: DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x0000000012d96b0c 6. /build/src/Functions/IFunction.cpp:577: DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x0000000012d9669c 7. /build/src/Functions/IFunction.cpp:606: DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x0000000012d96edc 8. /build/src/Functions/FunctionBinaryArithmetic.h:1742: DB::FunctionBinaryArithmetic::getReturnTypeImplStatic(std::vector, std::allocator>> const&, std::shared_ptr) @ 0x000000000e04d131 9. /build/src/Functions/IFunction.h:369: DB::IFunctionOverloadResolver::getReturnTypeImpl(std::vector> const&) const @ 0x000000000a6646de 10. /build/src/Functions/IFunction.cpp:645: DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x0000000012d96b0c 11. /build/src/Functions/IFunction.cpp:577: DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x0000000012d9669c 12. /build/src/Functions/IFunction.cpp:606: DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x0000000012d96edc 13. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3544: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000014033cc9 14. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3838: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000014019a9e 15. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3980: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000014018e31 16. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:4304: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000014042fa7 17. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5605: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000014013749 18. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000140127f9 19. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000014011fce 20. /build/src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000001406ce8a 21. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000014973b42 22. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000001497268d 23. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000014974d24 24. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001492924b 25. /build/src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88641 26. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 27. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 28. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 29. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 30. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 31. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 2025.07.28 12:03:00.502954 [ 62114 ] {} TCPHandler: Code: 43. DB::Exception: addNanoseconds cannot be used with Date: In scope SELECT toDate('2001-09-29') + toIntervalNanosecond(12345) AS x, toTypeName(x). (ILLEGAL_TYPE_OF_ARGUMENT), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000a06a8eb 4. /build/src/Functions/FunctionDateOrDateTimeAddInterval.h:696: std::shared_ptr DB::FunctionDateOrDateTimeAddInterval::resolveReturnType(std::vector> const&) const @ 0x000000000aa69096 5. /build/src/Functions/IFunction.cpp:645: DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x0000000012d96b0c 6. /build/src/Functions/IFunction.cpp:577: DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x0000000012d9669c 7. /build/src/Functions/IFunction.cpp:606: DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x0000000012d96edc 8. /build/src/Functions/FunctionBinaryArithmetic.h:1742: DB::FunctionBinaryArithmetic::getReturnTypeImplStatic(std::vector, std::allocator>> const&, std::shared_ptr) @ 0x000000000e04d131 9. /build/src/Functions/IFunction.h:369: DB::IFunctionOverloadResolver::getReturnTypeImpl(std::vector> const&) const @ 0x000000000a6646de 10. /build/src/Functions/IFunction.cpp:645: DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x0000000012d96b0c 11. /build/src/Functions/IFunction.cpp:577: DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x0000000012d9669c 12. /build/src/Functions/IFunction.cpp:606: DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x0000000012d96edc 13. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3544: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000014033cc9 14. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3838: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000014019a9e 15. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3980: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000014018e31 16. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:4304: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000014042fa7 17. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5605: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000014013749 18. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000140127f9 19. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000014011fce 20. /build/src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000001406ce8a 21. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000014973b42 22. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000001497268d 23. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000014974d24 24. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001492924b 25. /build/src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88641 26. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 27. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 28. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 29. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 30. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 31. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 2025.07.28 12:03:00.507605 [ 3970 ] {} test_13.rmt2 (7f9b740d-015c-470e-8cc6-8ba33be0dc63): auto DB::StorageReplicatedMergeTree::processQueueEntry(ReplicatedMergeTreeQueue::SelectedEntryPtr)::(anonymous class)::operator()(LogEntryPtr &) const: Code: 86. DB::HTTPException: Received error from remote server http://146b4357c08d:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Ftest%2F01165%2Ftest_13%2Frmt%2Freplicas%2F1&part=20250728_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.6.10636.altinitytest (altinity build)) '. (RECEIVED_ERROR_FROM_REMOTE_IO_SERVER), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.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 const&, int&&, String const&, unsigned long&&, String const&) @ 0x000000000feda8d9 4. /build/src/IO/HTTPCommon.cpp:104: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x000000000feda6e2 5. /build/src/IO/HTTPCommon.cpp:93: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x000000000feda537 6. /build/src/IO/ReadWriteBufferFromHTTP.cpp:277: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x000000001184a4c4 7. /build/src/IO/ReadWriteBufferFromHTTP.cpp:285: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x000000001184a615 8. /build/src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x000000001184ae59 9. /build/src/IO/ReadWriteBufferFromHTTP.cpp:472: void std::__function::__policy_invoker::__call_impl[abi:se190107]>(std::__function::__policy_storage const*) @ 0x000000001184cedd 10. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001184858b 11. /build/src/IO/ReadWriteBufferFromHTTP.cpp:465: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x000000001184bf0b 12. /build/src/IO/ReadBuffer.h:60: DB::ReadBuffer::next() @ 0x000000000a148c7b 13. /build/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) @ 0x0000000011849fb2 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]>&)>&, 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&) @ 0x0000000011841980 15. /build/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) @ 0x000000001621208e 16. /build/src/Storages/StorageReplicatedMergeTree.cpp:5228: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl[abi:se190107] const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000015f9a5fe 17. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000015ed8bfd 18. /build/src/Storages/StorageReplicatedMergeTree.cpp:2514: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x0000000015ec9aab 19. /build/src/Storages/StorageReplicatedMergeTree.cpp:2349: DB::StorageReplicatedMergeTree::executeLogEntry(DB::ReplicatedMergeTreeLogEntry&) @ 0x0000000015eba91b 20. /build/src/Storages/StorageReplicatedMergeTree.cpp:3876: bool std::__function::__policy_invoker&)>::__call_impl[abi:se190107])::$_1, bool (std::shared_ptr&)>>(std::__function::__policy_storage const*, std::shared_ptr&) @ 0x0000000015f9837e 21. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000165d6fc3 22. /build/src/Storages/StorageReplicatedMergeTree.cpp:3872: DB::StorageReplicatedMergeTree::processQueueEntry(std::shared_ptr) @ 0x0000000015efc18a 23. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001624c1b2 24. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000162f9c70 25. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x00000000162fa55a 26. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc6653 27. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000000fccc4c3 28. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc3d92 29. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fcca080 30. ? @ 0x00007fbc6213eac3 31. ? @ 0x00007fbc621d0850 (version 25.3.6.10636.altinitytest (altinity build)) 2025.07.28 12:03:00.509696 [ 4900 ] {0ca1910d-8bdf-4706-aeaf-a7c45828e33e} executeQuery: Code: 60. DB::Exception: Unknown table expression identifier 't_json_inference' in scope SELECT toTypeName(obj) FROM t_json_inference LIMIT 1. (UNKNOWN_TABLE) (version 25.3.6.10636.altinitytest (altinity build)) (from [::1]:59462) (comment: 01825_type_json_schema_inference.sh) (query 1, line 1) (in query: SELECT toTypeName(obj) FROM t_json_inference LIMIT 1), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x000000000a6a1e2b 4. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:4372: DB::QueryAnalyzer::initializeQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000001404440b 5. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5594: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000140135fb 6. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000140127f9 7. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000014011fce 8. /build/src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000001406ce8a 9. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000014973b42 10. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000001497268d 11. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000014974d24 12. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001492924b 13. /build/src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88641 14. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 15. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 16. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 17. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 18. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 19. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 20. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 21. ? @ 0x00007fbc6213eac3 22. ? @ 0x00007fbc621d0850 2025.07.28 12:03:00.524538 [ 4900 ] {} TCPHandler: Code: 60. DB::Exception: Unknown table expression identifier 't_json_inference' in scope SELECT toTypeName(obj) FROM t_json_inference LIMIT 1. (UNKNOWN_TABLE), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x000000000a6a1e2b 4. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:4372: DB::QueryAnalyzer::initializeQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000001404440b 5. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5594: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000140135fb 6. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000140127f9 7. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000014011fce 8. /build/src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000001406ce8a 9. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000014973b42 10. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000001497268d 11. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000014974d24 12. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001492924b 13. /build/src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88641 14. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 15. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 16. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 17. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 18. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 19. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 20. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 21. ? @ 0x00007fbc6213eac3 22. ? @ 0x00007fbc621d0850 2025.07.28 12:03:00.878029 [ 62114 ] {070b2f1c-545a-4785-9522-1a3841a74905} executeQuery: Code: 43. DB::Exception: subtractMilliseconds cannot be used with Date: In scope SELECT toDate('2001-09-29') - toIntervalMillisecond(12345) AS x, toTypeName(x). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.6.10636.altinitytest (altinity build)) (from [::1]:59358) (comment: 01099_operators_date_and_timestamp.sql) (query 20, line 23) (in query: select (date '2001-09-29' - interval 12345 millisecond) x, toTypeName(x);), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000a06a8eb 4. /build/src/Functions/FunctionDateOrDateTimeAddInterval.h:696: std::shared_ptr DB::FunctionDateOrDateTimeAddInterval::resolveReturnType(std::vector> const&) const @ 0x000000000e77f036 5. /build/src/Functions/IFunction.cpp:645: DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x0000000012d96b0c 6. /build/src/Functions/IFunction.cpp:577: DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x0000000012d9669c 7. /build/src/Functions/IFunction.cpp:606: DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x0000000012d96edc 8. /build/src/Functions/FunctionBinaryArithmetic.h:1742: DB::FunctionBinaryArithmetic::getReturnTypeImplStatic(std::vector, std::allocator>> const&, std::shared_ptr) @ 0x000000000d14f22c 9. /build/src/Functions/IFunction.h:369: DB::IFunctionOverloadResolver::getReturnTypeImpl(std::vector> const&) const @ 0x000000000a6646de 10. /build/src/Functions/IFunction.cpp:645: DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x0000000012d96b0c 11. /build/src/Functions/IFunction.cpp:577: DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x0000000012d9669c 12. /build/src/Functions/IFunction.cpp:606: DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x0000000012d96edc 13. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3544: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000014033cc9 14. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3838: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000014019a9e 15. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3980: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000014018e31 16. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:4304: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000014042fa7 17. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5605: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000014013749 18. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000140127f9 19. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000014011fce 20. /build/src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000001406ce8a 21. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000014973b42 22. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000001497268d 23. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000014974d24 24. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001492924b 25. /build/src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88641 26. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 27. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 28. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 29. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 30. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 31. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 2025.07.28 12:03:00.879839 [ 62058 ] {3753ded9-b450-4868-9b19-08dfdbd0476e} executeQuery: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=885, jobs=840). (CANNOT_SCHEDULE_TASK) (version 25.3.6.10636.altinitytest (altinity build)) (from [::1]:59436) (comment: 02352_grouby_shadows_arg.sql) (query 3, line 4) (in query: SELECT toString((toInt8(dummy)+2) * (toInt8(dummy)+2)) as dummy FROM remote('127.{1,1}', system.one) GROUP BY dummy;), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000fccaeeb 4. /build/src/Common/ThreadPool.cpp:275: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000fccacb3 5. /build/src/Common/ThreadPool.cpp:323: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fcc4ffc 6. /build/src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000000fcc584d 7. /build/src/Common/ThreadPool.h:279: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x00000000169bf193 8. /build/src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x00000000169bf518 9. /build/src/Server/TCPHandler.cpp:1237: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x00000000168f1525 10. /build/src/Server/TCPHandler.cpp:678: DB::TCPHandler::runImpl() @ 0x00000000168e68e5 11. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 12. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 13. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 14. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 15. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 16. ? @ 0x00007fbc6213eac3 17. ? @ 0x00007fbc621d0850 2025.07.28 12:03:00.880743 [ 62114 ] {} TCPHandler: Code: 43. DB::Exception: subtractMilliseconds cannot be used with Date: In scope SELECT toDate('2001-09-29') - toIntervalMillisecond(12345) AS x, toTypeName(x). (ILLEGAL_TYPE_OF_ARGUMENT), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000a06a8eb 4. /build/src/Functions/FunctionDateOrDateTimeAddInterval.h:696: std::shared_ptr DB::FunctionDateOrDateTimeAddInterval::resolveReturnType(std::vector> const&) const @ 0x000000000e77f036 5. /build/src/Functions/IFunction.cpp:645: DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x0000000012d96b0c 6. /build/src/Functions/IFunction.cpp:577: DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x0000000012d9669c 7. /build/src/Functions/IFunction.cpp:606: DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x0000000012d96edc 8. /build/src/Functions/FunctionBinaryArithmetic.h:1742: DB::FunctionBinaryArithmetic::getReturnTypeImplStatic(std::vector, std::allocator>> const&, std::shared_ptr) @ 0x000000000d14f22c 9. /build/src/Functions/IFunction.h:369: DB::IFunctionOverloadResolver::getReturnTypeImpl(std::vector> const&) const @ 0x000000000a6646de 10. /build/src/Functions/IFunction.cpp:645: DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x0000000012d96b0c 11. /build/src/Functions/IFunction.cpp:577: DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x0000000012d9669c 12. /build/src/Functions/IFunction.cpp:606: DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x0000000012d96edc 13. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3544: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000014033cc9 14. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3838: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000014019a9e 15. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3980: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000014018e31 16. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:4304: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000014042fa7 17. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5605: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000014013749 18. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000140127f9 19. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000014011fce 20. /build/src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000001406ce8a 21. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000014973b42 22. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000001497268d 23. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000014974d24 24. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001492924b 25. /build/src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88641 26. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 27. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 28. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 29. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 30. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 31. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 2025.07.28 12:03:00.896271 [ 62058 ] {} TCPHandler: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=885, jobs=840). (CANNOT_SCHEDULE_TASK), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000fccaeeb 4. /build/src/Common/ThreadPool.cpp:275: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000fccacb3 5. /build/src/Common/ThreadPool.cpp:323: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fcc4ffc 6. /build/src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000000fcc584d 7. /build/src/Common/ThreadPool.h:279: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x00000000169bf193 8. /build/src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x00000000169bf518 9. /build/src/Server/TCPHandler.cpp:1237: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x00000000168f1525 10. /build/src/Server/TCPHandler.cpp:678: DB::TCPHandler::runImpl() @ 0x00000000168e68e5 11. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 12. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 13. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 14. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 15. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 16. ? @ 0x00007fbc6213eac3 17. ? @ 0x00007fbc621d0850 2025.07.28 12:03:01.135967 [ 62114 ] {c20eec53-665b-407e-b69e-5071a9668b17} executeQuery: Code: 43. DB::Exception: subtractMicroseconds cannot be used with Date: In scope SELECT toDate('2001-09-29') - toIntervalMicrosecond(12345) AS x, toTypeName(x). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.6.10636.altinitytest (altinity build)) (from [::1]:59358) (comment: 01099_operators_date_and_timestamp.sql) (query 21, line 24) (in query: select (date '2001-09-29' - interval 12345 microsecond) x, toTypeName(x);), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000a06a8eb 4. /build/src/Functions/FunctionDateOrDateTimeAddInterval.h:696: std::shared_ptr DB::FunctionDateOrDateTimeAddInterval::resolveReturnType(std::vector> const&) const @ 0x000000000e76c6f6 5. /build/src/Functions/IFunction.cpp:645: DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x0000000012d96b0c 6. /build/src/Functions/IFunction.cpp:577: DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x0000000012d9669c 7. /build/src/Functions/IFunction.cpp:606: DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x0000000012d96edc 8. /build/src/Functions/FunctionBinaryArithmetic.h:1742: DB::FunctionBinaryArithmetic::getReturnTypeImplStatic(std::vector, std::allocator>> const&, std::shared_ptr) @ 0x000000000d14f22c 9. /build/src/Functions/IFunction.h:369: DB::IFunctionOverloadResolver::getReturnTypeImpl(std::vector> const&) const @ 0x000000000a6646de 10. /build/src/Functions/IFunction.cpp:645: DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x0000000012d96b0c 11. /build/src/Functions/IFunction.cpp:577: DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x0000000012d9669c 12. /build/src/Functions/IFunction.cpp:606: DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x0000000012d96edc 13. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3544: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000014033cc9 14. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3838: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000014019a9e 15. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3980: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000014018e31 16. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:4304: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000014042fa7 17. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5605: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000014013749 18. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000140127f9 19. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000014011fce 20. /build/src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000001406ce8a 21. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000014973b42 22. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000001497268d 23. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000014974d24 24. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001492924b 25. /build/src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88641 26. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 27. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 28. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 29. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 30. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 31. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 2025.07.28 12:03:01.138848 [ 17203 ] {} 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. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x000000000c25bc4b 4. /build/src/Access/SettingsConstraints.cpp:343: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000138596e3 5. /build/src/Access/SettingsConstraints.cpp:300: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000013858faf 6. /build/src/Access/SettingsConstraints.cpp:209: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x00000000138592b8 7. /build/src/Interpreters/Context.cpp:2690: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000014436134 8. /build/src/Interpreters/Context.cpp:2729: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x000000001443662b 9. /build/src/Server/TCPHandler.cpp:2158: DB::TCPHandler::processQuery(std::optional&) @ 0x00000000168f61df 10. /build/src/Server/TCPHandler.cpp:918: DB::TCPHandler::receivePacketsExpectQuery(std::optional&) @ 0x00000000168ef965 11. /build/src/Server/TCPHandler.cpp:491: DB::TCPHandler::runImpl() @ 0x00000000168e5eb4 12. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 13. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 14. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 16. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 17. ? @ 0x00007fbc6213eac3 18. ? @ 0x00007fbc621d0850 2025.07.28 12:03:01.143801 [ 17203 ] {} 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. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000000a074fcb 4. /build/src/Server/TCPHandler.cpp:897: DB::TCPHandler::receivePacketsExpectQuery(std::optional&) @ 0x00000000168efa89 5. /build/src/Server/TCPHandler.cpp:491: DB::TCPHandler::runImpl() @ 0x00000000168e5eb4 6. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 7. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 8. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 9. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 10. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 11. ? @ 0x00007fbc6213eac3 12. ? @ 0x00007fbc621d0850 2025.07.28 12:03:01.155735 [ 62114 ] {} TCPHandler: Code: 43. DB::Exception: subtractMicroseconds cannot be used with Date: In scope SELECT toDate('2001-09-29') - toIntervalMicrosecond(12345) AS x, toTypeName(x). (ILLEGAL_TYPE_OF_ARGUMENT), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000a06a8eb 4. /build/src/Functions/FunctionDateOrDateTimeAddInterval.h:696: std::shared_ptr DB::FunctionDateOrDateTimeAddInterval::resolveReturnType(std::vector> const&) const @ 0x000000000e76c6f6 5. /build/src/Functions/IFunction.cpp:645: DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x0000000012d96b0c 6. /build/src/Functions/IFunction.cpp:577: DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x0000000012d9669c 7. /build/src/Functions/IFunction.cpp:606: DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x0000000012d96edc 8. /build/src/Functions/FunctionBinaryArithmetic.h:1742: DB::FunctionBinaryArithmetic::getReturnTypeImplStatic(std::vector, std::allocator>> const&, std::shared_ptr) @ 0x000000000d14f22c 9. /build/src/Functions/IFunction.h:369: DB::IFunctionOverloadResolver::getReturnTypeImpl(std::vector> const&) const @ 0x000000000a6646de 10. /build/src/Functions/IFunction.cpp:645: DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x0000000012d96b0c 11. /build/src/Functions/IFunction.cpp:577: DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x0000000012d9669c 12. /build/src/Functions/IFunction.cpp:606: DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x0000000012d96edc 13. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3544: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000014033cc9 14. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3838: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000014019a9e 15. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3980: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000014018e31 16. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:4304: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000014042fa7 17. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5605: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000014013749 18. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000140127f9 19. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000014011fce 20. /build/src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000001406ce8a 21. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000014973b42 22. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000001497268d 23. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000014974d24 24. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001492924b 25. /build/src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88641 26. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 27. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 28. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 29. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 30. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 31. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 2025.07.28 12:03:01.406174 [ 62114 ] {9994ef8e-539c-483b-8f9e-f9eb6108b49d} executeQuery: Code: 43. DB::Exception: subtractNanoseconds cannot be used with Date: In scope SELECT toDate('2001-09-29') - toIntervalNanosecond(12345) AS x, toTypeName(x). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.6.10636.altinitytest (altinity build)) (from [::1]:59358) (comment: 01099_operators_date_and_timestamp.sql) (query 22, line 25) (in query: select (date '2001-09-29' - interval 12345 nanosecond) x, toTypeName(x);), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000a06a8eb 4. /build/src/Functions/FunctionDateOrDateTimeAddInterval.h:696: std::shared_ptr DB::FunctionDateOrDateTimeAddInterval::resolveReturnType(std::vector> const&) const @ 0x000000000e7b8d16 5. /build/src/Functions/IFunction.cpp:645: DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x0000000012d96b0c 6. /build/src/Functions/IFunction.cpp:577: DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x0000000012d9669c 7. /build/src/Functions/IFunction.cpp:606: DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x0000000012d96edc 8. /build/src/Functions/FunctionBinaryArithmetic.h:1742: DB::FunctionBinaryArithmetic::getReturnTypeImplStatic(std::vector, std::allocator>> const&, std::shared_ptr) @ 0x000000000d14f22c 9. /build/src/Functions/IFunction.h:369: DB::IFunctionOverloadResolver::getReturnTypeImpl(std::vector> const&) const @ 0x000000000a6646de 10. /build/src/Functions/IFunction.cpp:645: DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x0000000012d96b0c 11. /build/src/Functions/IFunction.cpp:577: DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x0000000012d9669c 12. /build/src/Functions/IFunction.cpp:606: DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x0000000012d96edc 13. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3544: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000014033cc9 14. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3838: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000014019a9e 15. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3980: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000014018e31 16. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:4304: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000014042fa7 17. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5605: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000014013749 18. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000140127f9 19. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000014011fce 20. /build/src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000001406ce8a 21. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000014973b42 22. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000001497268d 23. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000014974d24 24. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001492924b 25. /build/src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88641 26. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 27. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 28. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 29. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 30. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 31. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 2025.07.28 12:03:01.419053 [ 62114 ] {} TCPHandler: Code: 43. DB::Exception: subtractNanoseconds cannot be used with Date: In scope SELECT toDate('2001-09-29') - toIntervalNanosecond(12345) AS x, toTypeName(x). (ILLEGAL_TYPE_OF_ARGUMENT), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000a06a8eb 4. /build/src/Functions/FunctionDateOrDateTimeAddInterval.h:696: std::shared_ptr DB::FunctionDateOrDateTimeAddInterval::resolveReturnType(std::vector> const&) const @ 0x000000000e7b8d16 5. /build/src/Functions/IFunction.cpp:645: DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x0000000012d96b0c 6. /build/src/Functions/IFunction.cpp:577: DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x0000000012d9669c 7. /build/src/Functions/IFunction.cpp:606: DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x0000000012d96edc 8. /build/src/Functions/FunctionBinaryArithmetic.h:1742: DB::FunctionBinaryArithmetic::getReturnTypeImplStatic(std::vector, std::allocator>> const&, std::shared_ptr) @ 0x000000000d14f22c 9. /build/src/Functions/IFunction.h:369: DB::IFunctionOverloadResolver::getReturnTypeImpl(std::vector> const&) const @ 0x000000000a6646de 10. /build/src/Functions/IFunction.cpp:645: DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x0000000012d96b0c 11. /build/src/Functions/IFunction.cpp:577: DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x0000000012d9669c 12. /build/src/Functions/IFunction.cpp:606: DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x0000000012d96edc 13. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3544: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000014033cc9 14. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3838: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000014019a9e 15. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3980: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000014018e31 16. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:4304: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000014042fa7 17. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5605: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000014013749 18. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000140127f9 19. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000014011fce 20. /build/src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000001406ce8a 21. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000014973b42 22. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000001497268d 23. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000014974d24 24. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001492924b 25. /build/src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88641 26. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 27. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 28. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 29. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 30. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 31. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 2025.07.28 12:03:01.424286 [ 3969 ] {} test_13.rmt2 (7f9b740d-015c-470e-8cc6-8ba33be0dc63): auto DB::StorageReplicatedMergeTree::processQueueEntry(ReplicatedMergeTreeQueue::SelectedEntryPtr)::(anonymous class)::operator()(LogEntryPtr &) const: Code: 86. DB::HTTPException: Received error from remote server http://146b4357c08d:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Ftest%2F01165%2Ftest_13%2Frmt%2Freplicas%2F1&part=20250728_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.6.10636.altinitytest (altinity build)) '. (RECEIVED_ERROR_FROM_REMOTE_IO_SERVER), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.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 const&, int&&, String const&, unsigned long&&, String const&) @ 0x000000000feda8d9 4. /build/src/IO/HTTPCommon.cpp:104: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x000000000feda6e2 5. /build/src/IO/HTTPCommon.cpp:93: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x000000000feda537 6. /build/src/IO/ReadWriteBufferFromHTTP.cpp:277: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x000000001184a4c4 7. /build/src/IO/ReadWriteBufferFromHTTP.cpp:285: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x000000001184a615 8. /build/src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x000000001184ae59 9. /build/src/IO/ReadWriteBufferFromHTTP.cpp:472: void std::__function::__policy_invoker::__call_impl[abi:se190107]>(std::__function::__policy_storage const*) @ 0x000000001184cedd 10. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001184858b 11. /build/src/IO/ReadWriteBufferFromHTTP.cpp:465: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x000000001184bf0b 12. /build/src/IO/ReadBuffer.h:60: DB::ReadBuffer::next() @ 0x000000000a148c7b 13. /build/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) @ 0x0000000011849fb2 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]>&)>&, 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&) @ 0x0000000011841980 15. /build/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) @ 0x000000001621208e 16. /build/src/Storages/StorageReplicatedMergeTree.cpp:5228: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl[abi:se190107] const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000015f9a5fe 17. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000015ed8bfd 18. /build/src/Storages/StorageReplicatedMergeTree.cpp:2514: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x0000000015ec9aab 19. /build/src/Storages/StorageReplicatedMergeTree.cpp:2349: DB::StorageReplicatedMergeTree::executeLogEntry(DB::ReplicatedMergeTreeLogEntry&) @ 0x0000000015eba91b 20. /build/src/Storages/StorageReplicatedMergeTree.cpp:3876: bool std::__function::__policy_invoker&)>::__call_impl[abi:se190107])::$_1, bool (std::shared_ptr&)>>(std::__function::__policy_storage const*, std::shared_ptr&) @ 0x0000000015f9837e 21. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000165d6fc3 22. /build/src/Storages/StorageReplicatedMergeTree.cpp:3872: DB::StorageReplicatedMergeTree::processQueueEntry(std::shared_ptr) @ 0x0000000015efc18a 23. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001624c1b2 24. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000162f9c70 25. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x00000000162fa55a 26. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc6653 27. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000000fccc4c3 28. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc3d92 29. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fcca080 30. ? @ 0x00007fbc6213eac3 31. ? @ 0x00007fbc621d0850 (version 25.3.6.10636.altinitytest (altinity build)) 2025.07.28 12:03:01.667038 [ 62114 ] {ebf2ed99-4722-42eb-94ef-e76366632959} executeQuery: Code: 43. DB::Exception: addMilliseconds cannot be used with Date32: In scope SELECT toDate32('2001-09-29') + toIntervalMillisecond(12345) AS x, toTypeName(x). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.6.10636.altinitytest (altinity build)) (from [::1]:59358) (comment: 01099_operators_date_and_timestamp.sql) (query 24, line 27) (in query: select (toDate32('2001-09-29') + interval 12345 millisecond) x, toTypeName(x);), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000a06a8eb 4. /build/src/Functions/FunctionDateOrDateTimeAddInterval.h:696: std::shared_ptr DB::FunctionDateOrDateTimeAddInterval::resolveReturnType(std::vector> const&) const @ 0x000000000aa2e3b6 5. /build/src/Functions/IFunction.cpp:645: DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x0000000012d96b0c 6. /build/src/Functions/IFunction.cpp:577: DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x0000000012d9669c 7. /build/src/Functions/IFunction.cpp:606: DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x0000000012d96edc 8. /build/src/Functions/FunctionBinaryArithmetic.h:1742: DB::FunctionBinaryArithmetic::getReturnTypeImplStatic(std::vector, std::allocator>> const&, std::shared_ptr) @ 0x000000000e04d131 9. /build/src/Functions/IFunction.h:369: DB::IFunctionOverloadResolver::getReturnTypeImpl(std::vector> const&) const @ 0x000000000a6646de 10. /build/src/Functions/IFunction.cpp:645: DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x0000000012d96b0c 11. /build/src/Functions/IFunction.cpp:577: DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x0000000012d9669c 12. /build/src/Functions/IFunction.cpp:606: DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x0000000012d96edc 13. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3544: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000014033cc9 14. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3838: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000014019a9e 15. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3980: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000014018e31 16. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:4304: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000014042fa7 17. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5605: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000014013749 18. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000140127f9 19. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000014011fce 20. /build/src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000001406ce8a 21. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000014973b42 22. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000001497268d 23. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000014974d24 24. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001492924b 25. /build/src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88641 26. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 27. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 28. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 29. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 30. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 31. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 2025.07.28 12:03:01.669370 [ 62114 ] {} TCPHandler: Code: 43. DB::Exception: addMilliseconds cannot be used with Date32: In scope SELECT toDate32('2001-09-29') + toIntervalMillisecond(12345) AS x, toTypeName(x). (ILLEGAL_TYPE_OF_ARGUMENT), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000a06a8eb 4. /build/src/Functions/FunctionDateOrDateTimeAddInterval.h:696: std::shared_ptr DB::FunctionDateOrDateTimeAddInterval::resolveReturnType(std::vector> const&) const @ 0x000000000aa2e3b6 5. /build/src/Functions/IFunction.cpp:645: DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x0000000012d96b0c 6. /build/src/Functions/IFunction.cpp:577: DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x0000000012d9669c 7. /build/src/Functions/IFunction.cpp:606: DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x0000000012d96edc 8. /build/src/Functions/FunctionBinaryArithmetic.h:1742: DB::FunctionBinaryArithmetic::getReturnTypeImplStatic(std::vector, std::allocator>> const&, std::shared_ptr) @ 0x000000000e04d131 9. /build/src/Functions/IFunction.h:369: DB::IFunctionOverloadResolver::getReturnTypeImpl(std::vector> const&) const @ 0x000000000a6646de 10. /build/src/Functions/IFunction.cpp:645: DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x0000000012d96b0c 11. /build/src/Functions/IFunction.cpp:577: DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x0000000012d9669c 12. /build/src/Functions/IFunction.cpp:606: DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x0000000012d96edc 13. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3544: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000014033cc9 14. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3838: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000014019a9e 15. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3980: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000014018e31 16. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:4304: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000014042fa7 17. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5605: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000014013749 18. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000140127f9 19. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000014011fce 20. /build/src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000001406ce8a 21. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000014973b42 22. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000001497268d 23. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000014974d24 24. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001492924b 25. /build/src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88641 26. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 27. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 28. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 29. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 30. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 31. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 2025.07.28 12:03:01.827437 [ 62114 ] {b1963f42-5679-4d0b-86ff-0c9af44eb3ba} executeQuery: Code: 43. DB::Exception: addMicroseconds cannot be used with Date32: In scope SELECT toDate32('2001-09-29') + toIntervalMicrosecond(12345) AS x, toTypeName(x). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.6.10636.altinitytest (altinity build)) (from [::1]:59358) (comment: 01099_operators_date_and_timestamp.sql) (query 25, line 28) (in query: select (toDate32('2001-09-29') + interval 12345 microsecond) x, toTypeName(x);), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000a06a8eb 4. /build/src/Functions/FunctionDateOrDateTimeAddInterval.h:696: std::shared_ptr DB::FunctionDateOrDateTimeAddInterval::resolveReturnType(std::vector> const&) const @ 0x000000000aa1bf56 5. /build/src/Functions/IFunction.cpp:645: DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x0000000012d96b0c 6. /build/src/Functions/IFunction.cpp:577: DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x0000000012d9669c 7. /build/src/Functions/IFunction.cpp:606: DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x0000000012d96edc 8. /build/src/Functions/FunctionBinaryArithmetic.h:1742: DB::FunctionBinaryArithmetic::getReturnTypeImplStatic(std::vector, std::allocator>> const&, std::shared_ptr) @ 0x000000000e04d131 9. /build/src/Functions/IFunction.h:369: DB::IFunctionOverloadResolver::getReturnTypeImpl(std::vector> const&) const @ 0x000000000a6646de 10. /build/src/Functions/IFunction.cpp:645: DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x0000000012d96b0c 11. /build/src/Functions/IFunction.cpp:577: DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x0000000012d9669c 12. /build/src/Functions/IFunction.cpp:606: DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x0000000012d96edc 13. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3544: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000014033cc9 14. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3838: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000014019a9e 15. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3980: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000014018e31 16. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:4304: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000014042fa7 17. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5605: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000014013749 18. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000140127f9 19. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000014011fce 20. /build/src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000001406ce8a 21. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000014973b42 22. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000001497268d 23. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000014974d24 24. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001492924b 25. /build/src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88641 26. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 27. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 28. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 29. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 30. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 31. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 2025.07.28 12:03:01.847074 [ 62114 ] {} TCPHandler: Code: 43. DB::Exception: addMicroseconds cannot be used with Date32: In scope SELECT toDate32('2001-09-29') + toIntervalMicrosecond(12345) AS x, toTypeName(x). (ILLEGAL_TYPE_OF_ARGUMENT), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000a06a8eb 4. /build/src/Functions/FunctionDateOrDateTimeAddInterval.h:696: std::shared_ptr DB::FunctionDateOrDateTimeAddInterval::resolveReturnType(std::vector> const&) const @ 0x000000000aa1bf56 5. /build/src/Functions/IFunction.cpp:645: DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x0000000012d96b0c 6. /build/src/Functions/IFunction.cpp:577: DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x0000000012d9669c 7. /build/src/Functions/IFunction.cpp:606: DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x0000000012d96edc 8. /build/src/Functions/FunctionBinaryArithmetic.h:1742: DB::FunctionBinaryArithmetic::getReturnTypeImplStatic(std::vector, std::allocator>> const&, std::shared_ptr) @ 0x000000000e04d131 9. /build/src/Functions/IFunction.h:369: DB::IFunctionOverloadResolver::getReturnTypeImpl(std::vector> const&) const @ 0x000000000a6646de 10. /build/src/Functions/IFunction.cpp:645: DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x0000000012d96b0c 11. /build/src/Functions/IFunction.cpp:577: DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x0000000012d9669c 12. /build/src/Functions/IFunction.cpp:606: DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x0000000012d96edc 13. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3544: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000014033cc9 14. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3838: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000014019a9e 15. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3980: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000014018e31 16. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:4304: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000014042fa7 17. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5605: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000014013749 18. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000140127f9 19. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000014011fce 20. /build/src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000001406ce8a 21. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000014973b42 22. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000001497268d 23. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000014974d24 24. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001492924b 25. /build/src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88641 26. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 27. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 28. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 29. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 30. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 31. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 2025.07.28 12:03:02.059858 [ 3968 ] {} test_13.rmt2 (7f9b740d-015c-470e-8cc6-8ba33be0dc63): auto DB::StorageReplicatedMergeTree::processQueueEntry(ReplicatedMergeTreeQueue::SelectedEntryPtr)::(anonymous class)::operator()(LogEntryPtr &) const: Code: 86. DB::HTTPException: Received error from remote server http://146b4357c08d:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Ftest%2F01165%2Ftest_13%2Frmt%2Freplicas%2F1&part=20250728_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.6.10636.altinitytest (altinity build)) '. (RECEIVED_ERROR_FROM_REMOTE_IO_SERVER), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.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 const&, int&&, String const&, unsigned long&&, String const&) @ 0x000000000feda8d9 4. /build/src/IO/HTTPCommon.cpp:104: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x000000000feda6e2 5. /build/src/IO/HTTPCommon.cpp:93: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x000000000feda537 6. /build/src/IO/ReadWriteBufferFromHTTP.cpp:277: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x000000001184a4c4 7. /build/src/IO/ReadWriteBufferFromHTTP.cpp:285: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x000000001184a615 8. /build/src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x000000001184ae59 9. /build/src/IO/ReadWriteBufferFromHTTP.cpp:472: void std::__function::__policy_invoker::__call_impl[abi:se190107]>(std::__function::__policy_storage const*) @ 0x000000001184cedd 10. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001184858b 11. /build/src/IO/ReadWriteBufferFromHTTP.cpp:465: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x000000001184bf0b 12. /build/src/IO/ReadBuffer.h:60: DB::ReadBuffer::next() @ 0x000000000a148c7b 13. /build/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) @ 0x0000000011849fb2 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]>&)>&, 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&) @ 0x0000000011841980 15. /build/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) @ 0x000000001621208e 16. /build/src/Storages/StorageReplicatedMergeTree.cpp:5228: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl[abi:se190107] const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000015f9a5fe 17. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000015ed8bfd 18. /build/src/Storages/StorageReplicatedMergeTree.cpp:2514: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x0000000015ec9aab 19. /build/src/Storages/StorageReplicatedMergeTree.cpp:2349: DB::StorageReplicatedMergeTree::executeLogEntry(DB::ReplicatedMergeTreeLogEntry&) @ 0x0000000015eba91b 20. /build/src/Storages/StorageReplicatedMergeTree.cpp:3876: bool std::__function::__policy_invoker&)>::__call_impl[abi:se190107])::$_1, bool (std::shared_ptr&)>>(std::__function::__policy_storage const*, std::shared_ptr&) @ 0x0000000015f9837e 21. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000165d6fc3 22. /build/src/Storages/StorageReplicatedMergeTree.cpp:3872: DB::StorageReplicatedMergeTree::processQueueEntry(std::shared_ptr) @ 0x0000000015efc18a 23. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001624c1b2 24. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000162f9c70 25. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x00000000162fa55a 26. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc6653 27. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000000fccc4c3 28. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc3d92 29. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fcca080 30. ? @ 0x00007fbc6213eac3 31. ? @ 0x00007fbc621d0850 (version 25.3.6.10636.altinitytest (altinity build)) 2025.07.28 12:03:02.069928 [ 62114 ] {5816192f-a966-459e-a1dd-3abdaf9e78d1} executeQuery: Code: 43. DB::Exception: addNanoseconds cannot be used with Date32: In scope SELECT toDate32('2001-09-29') + toIntervalNanosecond(12345) AS x, toTypeName(x). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.6.10636.altinitytest (altinity build)) (from [::1]:59358) (comment: 01099_operators_date_and_timestamp.sql) (query 26, line 29) (in query: select (toDate32('2001-09-29') + interval 12345 nanosecond) x, toTypeName(x);), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000a06a8eb 4. /build/src/Functions/FunctionDateOrDateTimeAddInterval.h:696: std::shared_ptr DB::FunctionDateOrDateTimeAddInterval::resolveReturnType(std::vector> const&) const @ 0x000000000aa691f6 5. /build/src/Functions/IFunction.cpp:645: DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x0000000012d96b0c 6. /build/src/Functions/IFunction.cpp:577: DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x0000000012d9669c 7. /build/src/Functions/IFunction.cpp:606: DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x0000000012d96edc 8. /build/src/Functions/FunctionBinaryArithmetic.h:1742: DB::FunctionBinaryArithmetic::getReturnTypeImplStatic(std::vector, std::allocator>> const&, std::shared_ptr) @ 0x000000000e04d131 9. /build/src/Functions/IFunction.h:369: DB::IFunctionOverloadResolver::getReturnTypeImpl(std::vector> const&) const @ 0x000000000a6646de 10. /build/src/Functions/IFunction.cpp:645: DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x0000000012d96b0c 11. /build/src/Functions/IFunction.cpp:577: DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x0000000012d9669c 12. /build/src/Functions/IFunction.cpp:606: DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x0000000012d96edc 13. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3544: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000014033cc9 14. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3838: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000014019a9e 15. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3980: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000014018e31 16. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:4304: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000014042fa7 17. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5605: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000014013749 18. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000140127f9 19. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000014011fce 20. /build/src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000001406ce8a 21. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000014973b42 22. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000001497268d 23. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000014974d24 24. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001492924b 25. /build/src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88641 26. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 27. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 28. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 29. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 30. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 31. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 2025.07.28 12:03:02.084674 [ 62114 ] {} TCPHandler: Code: 43. DB::Exception: addNanoseconds cannot be used with Date32: In scope SELECT toDate32('2001-09-29') + toIntervalNanosecond(12345) AS x, toTypeName(x). (ILLEGAL_TYPE_OF_ARGUMENT), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000a06a8eb 4. /build/src/Functions/FunctionDateOrDateTimeAddInterval.h:696: std::shared_ptr DB::FunctionDateOrDateTimeAddInterval::resolveReturnType(std::vector> const&) const @ 0x000000000aa691f6 5. /build/src/Functions/IFunction.cpp:645: DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x0000000012d96b0c 6. /build/src/Functions/IFunction.cpp:577: DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x0000000012d9669c 7. /build/src/Functions/IFunction.cpp:606: DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x0000000012d96edc 8. /build/src/Functions/FunctionBinaryArithmetic.h:1742: DB::FunctionBinaryArithmetic::getReturnTypeImplStatic(std::vector, std::allocator>> const&, std::shared_ptr) @ 0x000000000e04d131 9. /build/src/Functions/IFunction.h:369: DB::IFunctionOverloadResolver::getReturnTypeImpl(std::vector> const&) const @ 0x000000000a6646de 10. /build/src/Functions/IFunction.cpp:645: DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x0000000012d96b0c 11. /build/src/Functions/IFunction.cpp:577: DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x0000000012d9669c 12. /build/src/Functions/IFunction.cpp:606: DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x0000000012d96edc 13. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3544: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000014033cc9 14. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3838: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000014019a9e 15. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3980: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000014018e31 16. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:4304: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000014042fa7 17. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5605: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000014013749 18. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000140127f9 19. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000014011fce 20. /build/src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000001406ce8a 21. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000014973b42 22. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000001497268d 23. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000014974d24 24. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001492924b 25. /build/src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88641 26. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 27. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 28. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 29. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 30. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 31. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 2025.07.28 12:03:02.271458 [ 3977 ] {} test_13.rmt2 (7f9b740d-015c-470e-8cc6-8ba33be0dc63): auto DB::StorageReplicatedMergeTree::processQueueEntry(ReplicatedMergeTreeQueue::SelectedEntryPtr)::(anonymous class)::operator()(LogEntryPtr &) const: Code: 86. DB::HTTPException: Received error from remote server http://146b4357c08d:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Ftest%2F01165%2Ftest_13%2Frmt%2Freplicas%2F1&part=20250728_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.6.10636.altinitytest (altinity build)) '. (RECEIVED_ERROR_FROM_REMOTE_IO_SERVER), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.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 const&, int&&, String const&, unsigned long&&, String const&) @ 0x000000000feda8d9 4. /build/src/IO/HTTPCommon.cpp:104: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x000000000feda6e2 5. /build/src/IO/HTTPCommon.cpp:93: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x000000000feda537 6. /build/src/IO/ReadWriteBufferFromHTTP.cpp:277: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x000000001184a4c4 7. /build/src/IO/ReadWriteBufferFromHTTP.cpp:285: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x000000001184a615 8. /build/src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x000000001184ae59 9. /build/src/IO/ReadWriteBufferFromHTTP.cpp:472: void std::__function::__policy_invoker::__call_impl[abi:se190107]>(std::__function::__policy_storage const*) @ 0x000000001184cedd 10. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001184858b 11. /build/src/IO/ReadWriteBufferFromHTTP.cpp:465: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x000000001184bf0b 12. /build/src/IO/ReadBuffer.h:60: DB::ReadBuffer::next() @ 0x000000000a148c7b 13. /build/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) @ 0x0000000011849fb2 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]>&)>&, 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&) @ 0x0000000011841980 15. /build/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) @ 0x000000001621208e 16. /build/src/Storages/StorageReplicatedMergeTree.cpp:5228: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl[abi:se190107] const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000015f9a5fe 17. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000015ed8bfd 18. /build/src/Storages/StorageReplicatedMergeTree.cpp:2514: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x0000000015ec9aab 19. /build/src/Storages/StorageReplicatedMergeTree.cpp:2349: DB::StorageReplicatedMergeTree::executeLogEntry(DB::ReplicatedMergeTreeLogEntry&) @ 0x0000000015eba91b 20. /build/src/Storages/StorageReplicatedMergeTree.cpp:3876: bool std::__function::__policy_invoker&)>::__call_impl[abi:se190107])::$_1, bool (std::shared_ptr&)>>(std::__function::__policy_storage const*, std::shared_ptr&) @ 0x0000000015f9837e 21. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000165d6fc3 22. /build/src/Storages/StorageReplicatedMergeTree.cpp:3872: DB::StorageReplicatedMergeTree::processQueueEntry(std::shared_ptr) @ 0x0000000015efc18a 23. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001624c1b2 24. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000162f9c70 25. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x00000000162fa55a 26. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc6653 27. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000000fccc4c3 28. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc3d92 29. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fcca080 30. ? @ 0x00007fbc6213eac3 31. ? @ 0x00007fbc621d0850 (version 25.3.6.10636.altinitytest (altinity build)) 2025.07.28 12:03:02.332238 [ 62114 ] {adddf152-c952-4c2e-b0de-5fde3294fdc9} executeQuery: Code: 43. DB::Exception: subtractMilliseconds cannot be used with Date32: In scope SELECT toDate32('2001-09-29') - toIntervalMillisecond(12345) AS x, toTypeName(x). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.6.10636.altinitytest (altinity build)) (from [::1]:59358) (comment: 01099_operators_date_and_timestamp.sql) (query 28, line 31) (in query: select (toDate32('2001-09-29') - interval 12345 millisecond) x, toTypeName(x);), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000a06a8eb 4. /build/src/Functions/FunctionDateOrDateTimeAddInterval.h:696: std::shared_ptr DB::FunctionDateOrDateTimeAddInterval::resolveReturnType(std::vector> const&) const @ 0x000000000e77f196 5. /build/src/Functions/IFunction.cpp:645: DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x0000000012d96b0c 6. /build/src/Functions/IFunction.cpp:577: DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x0000000012d9669c 7. /build/src/Functions/IFunction.cpp:606: DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x0000000012d96edc 8. /build/src/Functions/FunctionBinaryArithmetic.h:1742: DB::FunctionBinaryArithmetic::getReturnTypeImplStatic(std::vector, std::allocator>> const&, std::shared_ptr) @ 0x000000000d14f22c 9. /build/src/Functions/IFunction.h:369: DB::IFunctionOverloadResolver::getReturnTypeImpl(std::vector> const&) const @ 0x000000000a6646de 10. /build/src/Functions/IFunction.cpp:645: DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x0000000012d96b0c 11. /build/src/Functions/IFunction.cpp:577: DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x0000000012d9669c 12. /build/src/Functions/IFunction.cpp:606: DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x0000000012d96edc 13. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3544: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000014033cc9 14. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3838: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000014019a9e 15. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3980: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000014018e31 16. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:4304: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000014042fa7 17. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5605: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000014013749 18. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000140127f9 19. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000014011fce 20. /build/src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000001406ce8a 21. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000014973b42 22. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000001497268d 23. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000014974d24 24. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001492924b 25. /build/src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88641 26. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 27. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 28. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 29. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 30. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 31. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 2025.07.28 12:03:02.338454 [ 62114 ] {} TCPHandler: Code: 43. DB::Exception: subtractMilliseconds cannot be used with Date32: In scope SELECT toDate32('2001-09-29') - toIntervalMillisecond(12345) AS x, toTypeName(x). (ILLEGAL_TYPE_OF_ARGUMENT), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000a06a8eb 4. /build/src/Functions/FunctionDateOrDateTimeAddInterval.h:696: std::shared_ptr DB::FunctionDateOrDateTimeAddInterval::resolveReturnType(std::vector> const&) const @ 0x000000000e77f196 5. /build/src/Functions/IFunction.cpp:645: DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x0000000012d96b0c 6. /build/src/Functions/IFunction.cpp:577: DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x0000000012d9669c 7. /build/src/Functions/IFunction.cpp:606: DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x0000000012d96edc 8. /build/src/Functions/FunctionBinaryArithmetic.h:1742: DB::FunctionBinaryArithmetic::getReturnTypeImplStatic(std::vector, std::allocator>> const&, std::shared_ptr) @ 0x000000000d14f22c 9. /build/src/Functions/IFunction.h:369: DB::IFunctionOverloadResolver::getReturnTypeImpl(std::vector> const&) const @ 0x000000000a6646de 10. /build/src/Functions/IFunction.cpp:645: DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x0000000012d96b0c 11. /build/src/Functions/IFunction.cpp:577: DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x0000000012d9669c 12. /build/src/Functions/IFunction.cpp:606: DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x0000000012d96edc 13. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3544: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000014033cc9 14. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3838: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000014019a9e 15. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3980: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000014018e31 16. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:4304: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000014042fa7 17. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5605: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000014013749 18. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000140127f9 19. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000014011fce 20. /build/src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000001406ce8a 21. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000014973b42 22. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000001497268d 23. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000014974d24 24. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001492924b 25. /build/src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88641 26. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 27. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 28. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 29. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 30. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 31. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 2025.07.28 12:03:02.472008 [ 62114 ] {47613790-732a-45a5-be6e-bd1b02eef5dc} executeQuery: Code: 43. DB::Exception: subtractMicroseconds cannot be used with Date32: In scope SELECT toDate32('2001-09-29') - toIntervalMicrosecond(12345) AS x, toTypeName(x). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.6.10636.altinitytest (altinity build)) (from [::1]:59358) (comment: 01099_operators_date_and_timestamp.sql) (query 29, line 32) (in query: select (toDate32('2001-09-29') - interval 12345 microsecond) x, toTypeName(x);), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000a06a8eb 4. /build/src/Functions/FunctionDateOrDateTimeAddInterval.h:696: std::shared_ptr DB::FunctionDateOrDateTimeAddInterval::resolveReturnType(std::vector> const&) const @ 0x000000000e76c856 5. /build/src/Functions/IFunction.cpp:645: DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x0000000012d96b0c 6. /build/src/Functions/IFunction.cpp:577: DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x0000000012d9669c 7. /build/src/Functions/IFunction.cpp:606: DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x0000000012d96edc 8. /build/src/Functions/FunctionBinaryArithmetic.h:1742: DB::FunctionBinaryArithmetic::getReturnTypeImplStatic(std::vector, std::allocator>> const&, std::shared_ptr) @ 0x000000000d14f22c 9. /build/src/Functions/IFunction.h:369: DB::IFunctionOverloadResolver::getReturnTypeImpl(std::vector> const&) const @ 0x000000000a6646de 10. /build/src/Functions/IFunction.cpp:645: DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x0000000012d96b0c 11. /build/src/Functions/IFunction.cpp:577: DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x0000000012d9669c 12. /build/src/Functions/IFunction.cpp:606: DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x0000000012d96edc 13. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3544: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000014033cc9 14. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3838: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000014019a9e 15. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3980: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000014018e31 16. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:4304: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000014042fa7 17. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5605: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000014013749 18. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000140127f9 19. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000014011fce 20. /build/src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000001406ce8a 21. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000014973b42 22. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000001497268d 23. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000014974d24 24. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001492924b 25. /build/src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88641 26. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 27. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 28. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 29. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 30. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 31. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 2025.07.28 12:03:02.480654 [ 62114 ] {} TCPHandler: Code: 43. DB::Exception: subtractMicroseconds cannot be used with Date32: In scope SELECT toDate32('2001-09-29') - toIntervalMicrosecond(12345) AS x, toTypeName(x). (ILLEGAL_TYPE_OF_ARGUMENT), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000a06a8eb 4. /build/src/Functions/FunctionDateOrDateTimeAddInterval.h:696: std::shared_ptr DB::FunctionDateOrDateTimeAddInterval::resolveReturnType(std::vector> const&) const @ 0x000000000e76c856 5. /build/src/Functions/IFunction.cpp:645: DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x0000000012d96b0c 6. /build/src/Functions/IFunction.cpp:577: DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x0000000012d9669c 7. /build/src/Functions/IFunction.cpp:606: DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x0000000012d96edc 8. /build/src/Functions/FunctionBinaryArithmetic.h:1742: DB::FunctionBinaryArithmetic::getReturnTypeImplStatic(std::vector, std::allocator>> const&, std::shared_ptr) @ 0x000000000d14f22c 9. /build/src/Functions/IFunction.h:369: DB::IFunctionOverloadResolver::getReturnTypeImpl(std::vector> const&) const @ 0x000000000a6646de 10. /build/src/Functions/IFunction.cpp:645: DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x0000000012d96b0c 11. /build/src/Functions/IFunction.cpp:577: DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x0000000012d9669c 12. /build/src/Functions/IFunction.cpp:606: DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x0000000012d96edc 13. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3544: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000014033cc9 14. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3838: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000014019a9e 15. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3980: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000014018e31 16. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:4304: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000014042fa7 17. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5605: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000014013749 18. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000140127f9 19. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000014011fce 20. /build/src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000001406ce8a 21. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000014973b42 22. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000001497268d 23. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000014974d24 24. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001492924b 25. /build/src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88641 26. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 27. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 28. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 29. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 30. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 31. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 2025.07.28 12:03:02.703675 [ 62114 ] {fbf3f1c4-4d32-41e6-9804-c0d0e0ba56b2} executeQuery: Code: 43. DB::Exception: subtractNanoseconds cannot be used with Date32: In scope SELECT toDate32('2001-09-29') - toIntervalNanosecond(12345) AS x, toTypeName(x). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.6.10636.altinitytest (altinity build)) (from [::1]:59358) (comment: 01099_operators_date_and_timestamp.sql) (query 30, line 33) (in query: select (toDate32('2001-09-29') - interval 12345 nanosecond) x, toTypeName(x);), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000a06a8eb 4. /build/src/Functions/FunctionDateOrDateTimeAddInterval.h:696: std::shared_ptr DB::FunctionDateOrDateTimeAddInterval::resolveReturnType(std::vector> const&) const @ 0x000000000e7b8e76 5. /build/src/Functions/IFunction.cpp:645: DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x0000000012d96b0c 6. /build/src/Functions/IFunction.cpp:577: DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x0000000012d9669c 7. /build/src/Functions/IFunction.cpp:606: DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x0000000012d96edc 8. /build/src/Functions/FunctionBinaryArithmetic.h:1742: DB::FunctionBinaryArithmetic::getReturnTypeImplStatic(std::vector, std::allocator>> const&, std::shared_ptr) @ 0x000000000d14f22c 9. /build/src/Functions/IFunction.h:369: DB::IFunctionOverloadResolver::getReturnTypeImpl(std::vector> const&) const @ 0x000000000a6646de 10. /build/src/Functions/IFunction.cpp:645: DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x0000000012d96b0c 11. /build/src/Functions/IFunction.cpp:577: DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x0000000012d9669c 12. /build/src/Functions/IFunction.cpp:606: DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x0000000012d96edc 13. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3544: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000014033cc9 14. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3838: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000014019a9e 15. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3980: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000014018e31 16. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:4304: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000014042fa7 17. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5605: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000014013749 18. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000140127f9 19. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000014011fce 20. /build/src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000001406ce8a 21. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000014973b42 22. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000001497268d 23. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000014974d24 24. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001492924b 25. /build/src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88641 26. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 27. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 28. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 29. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 30. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 31. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 2025.07.28 12:03:02.706523 [ 3967 ] {} test_13.rmt2 (7f9b740d-015c-470e-8cc6-8ba33be0dc63): auto DB::StorageReplicatedMergeTree::processQueueEntry(ReplicatedMergeTreeQueue::SelectedEntryPtr)::(anonymous class)::operator()(LogEntryPtr &) const: Code: 86. DB::HTTPException: Received error from remote server http://146b4357c08d:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Ftest%2F01165%2Ftest_13%2Frmt%2Freplicas%2F1&part=20250728_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.6.10636.altinitytest (altinity build)) '. (RECEIVED_ERROR_FROM_REMOTE_IO_SERVER), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.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 const&, int&&, String const&, unsigned long&&, String const&) @ 0x000000000feda8d9 4. /build/src/IO/HTTPCommon.cpp:104: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x000000000feda6e2 5. /build/src/IO/HTTPCommon.cpp:93: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x000000000feda537 6. /build/src/IO/ReadWriteBufferFromHTTP.cpp:277: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x000000001184a4c4 7. /build/src/IO/ReadWriteBufferFromHTTP.cpp:285: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x000000001184a615 8. /build/src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x000000001184ae59 9. /build/src/IO/ReadWriteBufferFromHTTP.cpp:472: void std::__function::__policy_invoker::__call_impl[abi:se190107]>(std::__function::__policy_storage const*) @ 0x000000001184cedd 10. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001184858b 11. /build/src/IO/ReadWriteBufferFromHTTP.cpp:465: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x000000001184bf0b 12. /build/src/IO/ReadBuffer.h:60: DB::ReadBuffer::next() @ 0x000000000a148c7b 13. /build/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) @ 0x0000000011849fb2 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]>&)>&, 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&) @ 0x0000000011841980 15. /build/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) @ 0x000000001621208e 16. /build/src/Storages/StorageReplicatedMergeTree.cpp:5228: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl[abi:se190107] const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000015f9a5fe 17. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000015ed8bfd 18. /build/src/Storages/StorageReplicatedMergeTree.cpp:2514: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x0000000015ec9aab 19. /build/src/Storages/StorageReplicatedMergeTree.cpp:2349: DB::StorageReplicatedMergeTree::executeLogEntry(DB::ReplicatedMergeTreeLogEntry&) @ 0x0000000015eba91b 20. /build/src/Storages/StorageReplicatedMergeTree.cpp:3876: bool std::__function::__policy_invoker&)>::__call_impl[abi:se190107])::$_1, bool (std::shared_ptr&)>>(std::__function::__policy_storage const*, std::shared_ptr&) @ 0x0000000015f9837e 21. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000165d6fc3 22. /build/src/Storages/StorageReplicatedMergeTree.cpp:3872: DB::StorageReplicatedMergeTree::processQueueEntry(std::shared_ptr) @ 0x0000000015efc18a 23. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001624c1b2 24. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000162f9c70 25. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x00000000162fa55a 26. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc6653 27. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000000fccc4c3 28. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc3d92 29. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fcca080 30. ? @ 0x00007fbc6213eac3 31. ? @ 0x00007fbc621d0850 (version 25.3.6.10636.altinitytest (altinity build)) 2025.07.28 12:03:02.739853 [ 62114 ] {} TCPHandler: Code: 43. DB::Exception: subtractNanoseconds cannot be used with Date32: In scope SELECT toDate32('2001-09-29') - toIntervalNanosecond(12345) AS x, toTypeName(x). (ILLEGAL_TYPE_OF_ARGUMENT), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000a06a8eb 4. /build/src/Functions/FunctionDateOrDateTimeAddInterval.h:696: std::shared_ptr DB::FunctionDateOrDateTimeAddInterval::resolveReturnType(std::vector> const&) const @ 0x000000000e7b8e76 5. /build/src/Functions/IFunction.cpp:645: DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x0000000012d96b0c 6. /build/src/Functions/IFunction.cpp:577: DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x0000000012d9669c 7. /build/src/Functions/IFunction.cpp:606: DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x0000000012d96edc 8. /build/src/Functions/FunctionBinaryArithmetic.h:1742: DB::FunctionBinaryArithmetic::getReturnTypeImplStatic(std::vector, std::allocator>> const&, std::shared_ptr) @ 0x000000000d14f22c 9. /build/src/Functions/IFunction.h:369: DB::IFunctionOverloadResolver::getReturnTypeImpl(std::vector> const&) const @ 0x000000000a6646de 10. /build/src/Functions/IFunction.cpp:645: DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x0000000012d96b0c 11. /build/src/Functions/IFunction.cpp:577: DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x0000000012d9669c 12. /build/src/Functions/IFunction.cpp:606: DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x0000000012d96edc 13. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3544: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000014033cc9 14. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3838: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000014019a9e 15. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3980: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000014018e31 16. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:4304: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000014042fa7 17. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5605: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000014013749 18. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000140127f9 19. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000014011fce 20. /build/src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000001406ce8a 21. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000014973b42 22. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000001497268d 23. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000014974d24 24. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001492924b 25. /build/src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88641 26. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 27. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 28. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 29. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 30. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 31. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 2025.07.28 12:03:03.106756 [ 3962 ] {} test_13.rmt2 (7f9b740d-015c-470e-8cc6-8ba33be0dc63): auto DB::StorageReplicatedMergeTree::processQueueEntry(ReplicatedMergeTreeQueue::SelectedEntryPtr)::(anonymous class)::operator()(LogEntryPtr &) const: Code: 86. DB::HTTPException: Received error from remote server http://146b4357c08d:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Ftest%2F01165%2Ftest_13%2Frmt%2Freplicas%2F1&part=20250728_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.6.10636.altinitytest (altinity build)) '. (RECEIVED_ERROR_FROM_REMOTE_IO_SERVER), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.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 const&, int&&, String const&, unsigned long&&, String const&) @ 0x000000000feda8d9 4. /build/src/IO/HTTPCommon.cpp:104: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x000000000feda6e2 5. /build/src/IO/HTTPCommon.cpp:93: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x000000000feda537 6. /build/src/IO/ReadWriteBufferFromHTTP.cpp:277: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x000000001184a4c4 7. /build/src/IO/ReadWriteBufferFromHTTP.cpp:285: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x000000001184a615 8. /build/src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x000000001184ae59 9. /build/src/IO/ReadWriteBufferFromHTTP.cpp:472: void std::__function::__policy_invoker::__call_impl[abi:se190107]>(std::__function::__policy_storage const*) @ 0x000000001184cedd 10. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001184858b 11. /build/src/IO/ReadWriteBufferFromHTTP.cpp:465: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x000000001184bf0b 12. /build/src/IO/ReadBuffer.h:60: DB::ReadBuffer::next() @ 0x000000000a148c7b 13. /build/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) @ 0x0000000011849fb2 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]>&)>&, 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&) @ 0x0000000011841980 15. /build/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) @ 0x000000001621208e 16. /build/src/Storages/StorageReplicatedMergeTree.cpp:5228: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl[abi:se190107] const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000015f9a5fe 17. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000015ed8bfd 18. /build/src/Storages/StorageReplicatedMergeTree.cpp:2514: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x0000000015ec9aab 19. /build/src/Storages/StorageReplicatedMergeTree.cpp:2349: DB::StorageReplicatedMergeTree::executeLogEntry(DB::ReplicatedMergeTreeLogEntry&) @ 0x0000000015eba91b 20. /build/src/Storages/StorageReplicatedMergeTree.cpp:3876: bool std::__function::__policy_invoker&)>::__call_impl[abi:se190107])::$_1, bool (std::shared_ptr&)>>(std::__function::__policy_storage const*, std::shared_ptr&) @ 0x0000000015f9837e 21. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000165d6fc3 22. /build/src/Storages/StorageReplicatedMergeTree.cpp:3872: DB::StorageReplicatedMergeTree::processQueueEntry(std::shared_ptr) @ 0x0000000015efc18a 23. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001624c1b2 24. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000162f9c70 25. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x00000000162fa55a 26. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc6653 27. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000000fccc4c3 28. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc3d92 29. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fcca080 30. ? @ 0x00007fbc6213eac3 31. ? @ 0x00007fbc621d0850 (version 25.3.6.10636.altinitytest (altinity build)) 2025.07.28 12:03:03.799634 [ 3965 ] {} test_13.rmt2 (7f9b740d-015c-470e-8cc6-8ba33be0dc63): auto DB::StorageReplicatedMergeTree::processQueueEntry(ReplicatedMergeTreeQueue::SelectedEntryPtr)::(anonymous class)::operator()(LogEntryPtr &) const: Code: 86. DB::HTTPException: Received error from remote server http://146b4357c08d:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Ftest%2F01165%2Ftest_13%2Frmt%2Freplicas%2F1&part=20250728_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.6.10636.altinitytest (altinity build)) '. (RECEIVED_ERROR_FROM_REMOTE_IO_SERVER), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.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 const&, int&&, String const&, unsigned long&&, String const&) @ 0x000000000feda8d9 4. /build/src/IO/HTTPCommon.cpp:104: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x000000000feda6e2 5. /build/src/IO/HTTPCommon.cpp:93: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x000000000feda537 6. /build/src/IO/ReadWriteBufferFromHTTP.cpp:277: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x000000001184a4c4 7. /build/src/IO/ReadWriteBufferFromHTTP.cpp:285: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x000000001184a615 8. /build/src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x000000001184ae59 9. /build/src/IO/ReadWriteBufferFromHTTP.cpp:472: void std::__function::__policy_invoker::__call_impl[abi:se190107]>(std::__function::__policy_storage const*) @ 0x000000001184cedd 10. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001184858b 11. /build/src/IO/ReadWriteBufferFromHTTP.cpp:465: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x000000001184bf0b 12. /build/src/IO/ReadBuffer.h:60: DB::ReadBuffer::next() @ 0x000000000a148c7b 13. /build/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) @ 0x0000000011849fb2 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]>&)>&, 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&) @ 0x0000000011841980 15. /build/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) @ 0x000000001621208e 16. /build/src/Storages/StorageReplicatedMergeTree.cpp:5228: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl[abi:se190107] const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000015f9a5fe 17. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000015ed8bfd 18. /build/src/Storages/StorageReplicatedMergeTree.cpp:2514: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x0000000015ec9aab 19. /build/src/Storages/StorageReplicatedMergeTree.cpp:2349: DB::StorageReplicatedMergeTree::executeLogEntry(DB::ReplicatedMergeTreeLogEntry&) @ 0x0000000015eba91b 20. /build/src/Storages/StorageReplicatedMergeTree.cpp:3876: bool std::__function::__policy_invoker&)>::__call_impl[abi:se190107])::$_1, bool (std::shared_ptr&)>>(std::__function::__policy_storage const*, std::shared_ptr&) @ 0x0000000015f9837e 21. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000165d6fc3 22. /build/src/Storages/StorageReplicatedMergeTree.cpp:3872: DB::StorageReplicatedMergeTree::processQueueEntry(std::shared_ptr) @ 0x0000000015efc18a 23. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001624c1b2 24. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000162f9c70 25. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x00000000162fa55a 26. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc6653 27. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000000fccc4c3 28. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc3d92 29. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fcca080 30. ? @ 0x00007fbc6213eac3 31. ? @ 0x00007fbc621d0850 (version 25.3.6.10636.altinitytest (altinity build)) 2025.07.28 12:03:03.824469 [ 4900 ] {9d48b89a-4e31-4348-beaf-78f5c0ac352a} 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.6.10636.altinitytest (altinity build)) (from [::1]:59532) (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. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&) @ 0x000000000a10182b 4. /build/src/Functions/tupleHammingDistance.cpp:58: DB::FunctionTupleHammingDistance::getReturnTypeImpl(std::vector> const&) const @ 0x000000000e939df3 5. /build/src/Functions/IFunction.cpp:645: DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x0000000012d96b0c 6. /build/src/Functions/IFunction.cpp:577: DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x0000000012d9669c 7. /build/src/Functions/IFunction.cpp:606: DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x0000000012d96edc 8. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3544: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000014033cc9 9. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3838: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000014019a9e 10. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3980: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000014018e31 11. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:4304: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000014042fa7 12. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5605: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000014013749 13. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000140127f9 14. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000014011fce 15. /build/src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000001406ce8a 16. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000014973b42 17. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000001497268d 18. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000014974d24 19. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001492924b 20. /build/src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88641 21. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 22. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 23. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 24. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 25. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 26. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 27. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 28. ? @ 0x00007fbc6213eac3 29. ? @ 0x00007fbc621d0850 2025.07.28 12:03:03.833328 [ 4900 ] {} 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. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&) @ 0x000000000a10182b 4. /build/src/Functions/tupleHammingDistance.cpp:58: DB::FunctionTupleHammingDistance::getReturnTypeImpl(std::vector> const&) const @ 0x000000000e939df3 5. /build/src/Functions/IFunction.cpp:645: DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x0000000012d96b0c 6. /build/src/Functions/IFunction.cpp:577: DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x0000000012d9669c 7. /build/src/Functions/IFunction.cpp:606: DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x0000000012d96edc 8. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3544: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000014033cc9 9. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3838: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000014019a9e 10. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3980: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000014018e31 11. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:4304: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000014042fa7 12. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5605: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000014013749 13. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000140127f9 14. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000014011fce 15. /build/src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000001406ce8a 16. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000014973b42 17. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000001497268d 18. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000014974d24 19. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001492924b 20. /build/src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88641 21. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 22. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 23. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 24. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 25. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 26. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 27. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 28. ? @ 0x00007fbc6213eac3 29. ? @ 0x00007fbc621d0850 2025.07.28 12:03:03.868521 [ 4900 ] {2e452d8b-974a-4420-891b-f006aec2c804} 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.6.10636.altinitytest (altinity build)) (from [::1]:59532) (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. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception>&>(int, FormatStringHelperImpl::type, std::type_identity>&>::type>, String&&, std::basic_string_view>&) @ 0x000000000de9098b 4. /build/src/DataTypes/getLeastSupertype.cpp:69: std::shared_ptr DB::(anonymous namespace)::throwOrReturn<(DB::LeastSupertypeOnError)0, std::vector, std::allocator>>>(std::vector, std::allocator>> const&, std::basic_string_view>, int) @ 0x0000000013c6a73e 5. /build/src/DataTypes/getLeastSupertype.cpp:547: std::shared_ptr DB::getLeastSupertype<(DB::LeastSupertypeOnError)0>(std::vector, std::allocator>> const&) @ 0x0000000013c6dd15 6. /build/src/Functions/FunctionsComparison.h:1149: DB::FunctionComparison::executeGeneric(DB::ColumnWithTypeAndName const&, DB::ColumnWithTypeAndName const&) const @ 0x000000000db4a3f3 7. /build/src/Functions/FunctionsComparison.h:1429: DB::FunctionComparison::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000db31754 8. /build/src/Functions/IFunctionAdaptors.cpp:10: DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000012d995fa 9. /build/src/Functions/IFunction.cpp:353: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d93b52 10. /build/src/Functions/IFunction.cpp:420: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d95059 11. /build/src/Functions/IFunction.cpp:498: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d95c72 12. /build/src/Functions/IFunction.cpp:513: DB::IFunctionBase::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d96059 13. /build/src/Functions/tupleHammingDistance.cpp:122: DB::FunctionTupleHammingDistance::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000e93791c 14. /build/src/Functions/IFunction.h:437: DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000a069f2a 15. /build/src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000012d9965a 16. /build/src/Functions/IFunction.cpp:351: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d93b02 17. /build/src/Functions/IFunction.cpp:177: DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d93698 18. /build/src/Functions/IFunction.cpp:343: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d93aad 19. /build/src/Functions/IFunction.cpp:420: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d95059 20. /build/src/Functions/IFunction.cpp:498: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d95c72 21. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3567: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000014034494 22. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3838: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000014019a9e 23. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3980: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000014018e31 24. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:4304: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000014042fa7 25. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5605: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000014013749 26. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000140127f9 27. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000014011fce 28. /build/src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000001406ce8a 29. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000014973b42 30. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000001497268d 31. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000014974d24 2025.07.28 12:03:03.876153 [ 4900 ] {} 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. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception>&>(int, FormatStringHelperImpl::type, std::type_identity>&>::type>, String&&, std::basic_string_view>&) @ 0x000000000de9098b 4. /build/src/DataTypes/getLeastSupertype.cpp:69: std::shared_ptr DB::(anonymous namespace)::throwOrReturn<(DB::LeastSupertypeOnError)0, std::vector, std::allocator>>>(std::vector, std::allocator>> const&, std::basic_string_view>, int) @ 0x0000000013c6a73e 5. /build/src/DataTypes/getLeastSupertype.cpp:547: std::shared_ptr DB::getLeastSupertype<(DB::LeastSupertypeOnError)0>(std::vector, std::allocator>> const&) @ 0x0000000013c6dd15 6. /build/src/Functions/FunctionsComparison.h:1149: DB::FunctionComparison::executeGeneric(DB::ColumnWithTypeAndName const&, DB::ColumnWithTypeAndName const&) const @ 0x000000000db4a3f3 7. /build/src/Functions/FunctionsComparison.h:1429: DB::FunctionComparison::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000db31754 8. /build/src/Functions/IFunctionAdaptors.cpp:10: DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000012d995fa 9. /build/src/Functions/IFunction.cpp:353: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d93b52 10. /build/src/Functions/IFunction.cpp:420: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d95059 11. /build/src/Functions/IFunction.cpp:498: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d95c72 12. /build/src/Functions/IFunction.cpp:513: DB::IFunctionBase::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d96059 13. /build/src/Functions/tupleHammingDistance.cpp:122: DB::FunctionTupleHammingDistance::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000e93791c 14. /build/src/Functions/IFunction.h:437: DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000a069f2a 15. /build/src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000012d9965a 16. /build/src/Functions/IFunction.cpp:351: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d93b02 17. /build/src/Functions/IFunction.cpp:177: DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d93698 18. /build/src/Functions/IFunction.cpp:343: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d93aad 19. /build/src/Functions/IFunction.cpp:420: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d95059 20. /build/src/Functions/IFunction.cpp:498: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d95c72 21. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3567: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000014034494 22. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3838: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000014019a9e 23. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3980: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000014018e31 24. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:4304: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000014042fa7 25. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5605: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000014013749 26. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000140127f9 27. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000014011fce 28. /build/src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000001406ce8a 29. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000014973b42 30. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000001497268d 31. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000014974d24 2025.07.28 12:03:03.934976 [ 4900 ] {ea6b4e9b-8cba-402f-85bd-da55e4f9ea3e} 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.6.10636.altinitytest (altinity build)) (from [::1]:59532) (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. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception>&>(int, FormatStringHelperImpl::type, std::type_identity>&>::type>, String&&, std::basic_string_view>&) @ 0x000000000de9098b 4. /build/src/DataTypes/getLeastSupertype.cpp:69: std::shared_ptr DB::(anonymous namespace)::throwOrReturn<(DB::LeastSupertypeOnError)0, std::vector, std::allocator>>>(std::vector, std::allocator>> const&, std::basic_string_view>, int) @ 0x0000000013c6a73e 5. /build/src/DataTypes/getLeastSupertype.cpp:547: std::shared_ptr DB::getLeastSupertype<(DB::LeastSupertypeOnError)0>(std::vector, std::allocator>> const&) @ 0x0000000013c6dd15 6. /build/src/Functions/FunctionsComparison.h:1149: DB::FunctionComparison::executeGeneric(DB::ColumnWithTypeAndName const&, DB::ColumnWithTypeAndName const&) const @ 0x000000000db4a3f3 7. /build/src/Functions/FunctionsComparison.h:1429: DB::FunctionComparison::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000db31754 8. /build/src/Functions/IFunctionAdaptors.cpp:10: DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000012d995fa 9. /build/src/Functions/IFunction.cpp:353: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d93b52 10. /build/src/Functions/IFunction.cpp:420: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d95059 11. /build/src/Functions/IFunction.cpp:498: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d95c72 12. /build/src/Functions/IFunction.cpp:513: DB::IFunctionBase::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d96059 13. /build/src/Functions/tupleHammingDistance.cpp:122: DB::FunctionTupleHammingDistance::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000e93791c 14. /build/src/Functions/IFunction.h:437: DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000a069f2a 15. /build/src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000012d9965a 16. /build/src/Functions/IFunction.cpp:351: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d93b02 17. /build/src/Functions/IFunction.cpp:177: DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d93698 18. /build/src/Functions/IFunction.cpp:343: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d93aad 19. /build/src/Functions/IFunction.cpp:420: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d95059 20. /build/src/Functions/IFunction.cpp:498: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d95c72 21. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3567: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000014034494 22. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3838: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000014019a9e 23. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3980: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000014018e31 24. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:4304: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000014042fa7 25. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5605: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000014013749 26. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000140127f9 27. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000014011fce 28. /build/src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000001406ce8a 29. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000014973b42 30. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000001497268d 31. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000014974d24 2025.07.28 12:03:03.942750 [ 4900 ] {} 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. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception>&>(int, FormatStringHelperImpl::type, std::type_identity>&>::type>, String&&, std::basic_string_view>&) @ 0x000000000de9098b 4. /build/src/DataTypes/getLeastSupertype.cpp:69: std::shared_ptr DB::(anonymous namespace)::throwOrReturn<(DB::LeastSupertypeOnError)0, std::vector, std::allocator>>>(std::vector, std::allocator>> const&, std::basic_string_view>, int) @ 0x0000000013c6a73e 5. /build/src/DataTypes/getLeastSupertype.cpp:547: std::shared_ptr DB::getLeastSupertype<(DB::LeastSupertypeOnError)0>(std::vector, std::allocator>> const&) @ 0x0000000013c6dd15 6. /build/src/Functions/FunctionsComparison.h:1149: DB::FunctionComparison::executeGeneric(DB::ColumnWithTypeAndName const&, DB::ColumnWithTypeAndName const&) const @ 0x000000000db4a3f3 7. /build/src/Functions/FunctionsComparison.h:1429: DB::FunctionComparison::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000db31754 8. /build/src/Functions/IFunctionAdaptors.cpp:10: DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000012d995fa 9. /build/src/Functions/IFunction.cpp:353: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d93b52 10. /build/src/Functions/IFunction.cpp:420: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d95059 11. /build/src/Functions/IFunction.cpp:498: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d95c72 12. /build/src/Functions/IFunction.cpp:513: DB::IFunctionBase::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d96059 13. /build/src/Functions/tupleHammingDistance.cpp:122: DB::FunctionTupleHammingDistance::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000e93791c 14. /build/src/Functions/IFunction.h:437: DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000a069f2a 15. /build/src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000012d9965a 16. /build/src/Functions/IFunction.cpp:351: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d93b02 17. /build/src/Functions/IFunction.cpp:177: DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d93698 18. /build/src/Functions/IFunction.cpp:343: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d93aad 19. /build/src/Functions/IFunction.cpp:420: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d95059 20. /build/src/Functions/IFunction.cpp:498: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d95c72 21. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3567: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000014034494 22. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3838: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000014019a9e 23. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3980: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000014018e31 24. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:4304: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000014042fa7 25. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5605: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000014013749 26. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000140127f9 27. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000014011fce 28. /build/src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000001406ce8a 29. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000014973b42 30. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000001497268d 31. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000014974d24 2025.07.28 12:03:04.132384 [ 3970 ] {} test_13.rmt2 (7f9b740d-015c-470e-8cc6-8ba33be0dc63): auto DB::StorageReplicatedMergeTree::processQueueEntry(ReplicatedMergeTreeQueue::SelectedEntryPtr)::(anonymous class)::operator()(LogEntryPtr &) const: Code: 86. DB::HTTPException: Received error from remote server http://146b4357c08d:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Ftest%2F01165%2Ftest_13%2Frmt%2Freplicas%2F1&part=20250728_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.6.10636.altinitytest (altinity build)) '. (RECEIVED_ERROR_FROM_REMOTE_IO_SERVER), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.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 const&, int&&, String const&, unsigned long&&, String const&) @ 0x000000000feda8d9 4. /build/src/IO/HTTPCommon.cpp:104: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x000000000feda6e2 5. /build/src/IO/HTTPCommon.cpp:93: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x000000000feda537 6. /build/src/IO/ReadWriteBufferFromHTTP.cpp:277: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x000000001184a4c4 7. /build/src/IO/ReadWriteBufferFromHTTP.cpp:285: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x000000001184a615 8. /build/src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x000000001184ae59 9. /build/src/IO/ReadWriteBufferFromHTTP.cpp:472: void std::__function::__policy_invoker::__call_impl[abi:se190107]>(std::__function::__policy_storage const*) @ 0x000000001184cedd 10. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001184858b 11. /build/src/IO/ReadWriteBufferFromHTTP.cpp:465: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x000000001184bf0b 12. /build/src/IO/ReadBuffer.h:60: DB::ReadBuffer::next() @ 0x000000000a148c7b 13. /build/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) @ 0x0000000011849fb2 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]>&)>&, 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&) @ 0x0000000011841980 15. /build/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) @ 0x000000001621208e 16. /build/src/Storages/StorageReplicatedMergeTree.cpp:5228: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl[abi:se190107] const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000015f9a5fe 17. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000015ed8bfd 18. /build/src/Storages/StorageReplicatedMergeTree.cpp:2514: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x0000000015ec9aab 19. /build/src/Storages/StorageReplicatedMergeTree.cpp:2349: DB::StorageReplicatedMergeTree::executeLogEntry(DB::ReplicatedMergeTreeLogEntry&) @ 0x0000000015eba91b 20. /build/src/Storages/StorageReplicatedMergeTree.cpp:3876: bool std::__function::__policy_invoker&)>::__call_impl[abi:se190107])::$_1, bool (std::shared_ptr&)>>(std::__function::__policy_storage const*, std::shared_ptr&) @ 0x0000000015f9837e 21. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000165d6fc3 22. /build/src/Storages/StorageReplicatedMergeTree.cpp:3872: DB::StorageReplicatedMergeTree::processQueueEntry(std::shared_ptr) @ 0x0000000015efc18a 23. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001624c1b2 24. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000162f9c70 25. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x00000000162fa55a 26. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc6653 27. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000000fccc4c3 28. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc3d92 29. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fcca080 30. ? @ 0x00007fbc6213eac3 31. ? @ 0x00007fbc621d0850 (version 25.3.6.10636.altinitytest (altinity build)) 2025.07.28 12:03:04.385148 [ 3969 ] {} test_13.rmt2 (7f9b740d-015c-470e-8cc6-8ba33be0dc63): auto DB::StorageReplicatedMergeTree::processQueueEntry(ReplicatedMergeTreeQueue::SelectedEntryPtr)::(anonymous class)::operator()(LogEntryPtr &) const: Code: 86. DB::HTTPException: Received error from remote server http://146b4357c08d:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Ftest%2F01165%2Ftest_13%2Frmt%2Freplicas%2F1&part=20250728_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.6.10636.altinitytest (altinity build)) '. (RECEIVED_ERROR_FROM_REMOTE_IO_SERVER), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.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 const&, int&&, String const&, unsigned long&&, String const&) @ 0x000000000feda8d9 4. /build/src/IO/HTTPCommon.cpp:104: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x000000000feda6e2 5. /build/src/IO/HTTPCommon.cpp:93: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x000000000feda537 6. /build/src/IO/ReadWriteBufferFromHTTP.cpp:277: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x000000001184a4c4 7. /build/src/IO/ReadWriteBufferFromHTTP.cpp:285: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x000000001184a615 8. /build/src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x000000001184ae59 9. /build/src/IO/ReadWriteBufferFromHTTP.cpp:472: void std::__function::__policy_invoker::__call_impl[abi:se190107]>(std::__function::__policy_storage const*) @ 0x000000001184cedd 10. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001184858b 11. /build/src/IO/ReadWriteBufferFromHTTP.cpp:465: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x000000001184bf0b 12. /build/src/IO/ReadBuffer.h:60: DB::ReadBuffer::next() @ 0x000000000a148c7b 13. /build/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) @ 0x0000000011849fb2 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]>&)>&, 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&) @ 0x0000000011841980 15. /build/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) @ 0x000000001621208e 16. /build/src/Storages/StorageReplicatedMergeTree.cpp:5228: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl[abi:se190107] const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000015f9a5fe 17. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000015ed8bfd 18. /build/src/Storages/StorageReplicatedMergeTree.cpp:2514: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x0000000015ec9aab 19. /build/src/Storages/StorageReplicatedMergeTree.cpp:2349: DB::StorageReplicatedMergeTree::executeLogEntry(DB::ReplicatedMergeTreeLogEntry&) @ 0x0000000015eba91b 20. /build/src/Storages/StorageReplicatedMergeTree.cpp:3876: bool std::__function::__policy_invoker&)>::__call_impl[abi:se190107])::$_1, bool (std::shared_ptr&)>>(std::__function::__policy_storage const*, std::shared_ptr&) @ 0x0000000015f9837e 21. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000165d6fc3 22. /build/src/Storages/StorageReplicatedMergeTree.cpp:3872: DB::StorageReplicatedMergeTree::processQueueEntry(std::shared_ptr) @ 0x0000000015efc18a 23. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001624c1b2 24. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000162f9c70 25. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x00000000162fa55a 26. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc6653 27. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000000fccc4c3 28. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc3d92 29. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fcca080 30. ? @ 0x00007fbc6213eac3 31. ? @ 0x00007fbc621d0850 (version 25.3.6.10636.altinitytest (altinity build)) 2025.07.28 12:03:05.056993 [ 4900 ] {} 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. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x000000000c25bc4b 4. /build/src/Access/SettingsConstraints.cpp:343: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000138596e3 5. /build/src/Access/SettingsConstraints.cpp:300: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000013858faf 6. /build/src/Access/SettingsConstraints.cpp:209: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x00000000138592b8 7. /build/src/Interpreters/Context.cpp:2690: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000014436134 8. /build/src/Interpreters/Context.cpp:2729: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x000000001443662b 9. /build/src/Server/TCPHandler.cpp:2158: DB::TCPHandler::processQuery(std::optional&) @ 0x00000000168f61df 10. /build/src/Server/TCPHandler.cpp:918: DB::TCPHandler::receivePacketsExpectQuery(std::optional&) @ 0x00000000168ef965 11. /build/src/Server/TCPHandler.cpp:491: DB::TCPHandler::runImpl() @ 0x00000000168e5eb4 12. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 13. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 14. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 16. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 17. ? @ 0x00007fbc6213eac3 18. ? @ 0x00007fbc621d0850 2025.07.28 12:03:05.059848 [ 4900 ] {} 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. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000000a074fcb 4. /build/src/Server/TCPHandler.cpp:897: DB::TCPHandler::receivePacketsExpectQuery(std::optional&) @ 0x00000000168efa89 5. /build/src/Server/TCPHandler.cpp:491: DB::TCPHandler::runImpl() @ 0x00000000168e5eb4 6. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 7. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 8. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 9. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 10. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 11. ? @ 0x00007fbc6213eac3 12. ? @ 0x00007fbc621d0850 2025.07.28 12:03:05.477659 [ 3971 ] {} test_13.rmt2 (7f9b740d-015c-470e-8cc6-8ba33be0dc63): auto DB::StorageReplicatedMergeTree::processQueueEntry(ReplicatedMergeTreeQueue::SelectedEntryPtr)::(anonymous class)::operator()(LogEntryPtr &) const: Code: 86. DB::HTTPException: Received error from remote server http://146b4357c08d:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Ftest%2F01165%2Ftest_13%2Frmt%2Freplicas%2F1&part=20250728_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.6.10636.altinitytest (altinity build)) '. (RECEIVED_ERROR_FROM_REMOTE_IO_SERVER), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.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 const&, int&&, String const&, unsigned long&&, String const&) @ 0x000000000feda8d9 4. /build/src/IO/HTTPCommon.cpp:104: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x000000000feda6e2 5. /build/src/IO/HTTPCommon.cpp:93: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x000000000feda537 6. /build/src/IO/ReadWriteBufferFromHTTP.cpp:277: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x000000001184a4c4 7. /build/src/IO/ReadWriteBufferFromHTTP.cpp:285: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x000000001184a615 8. /build/src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x000000001184ae59 9. /build/src/IO/ReadWriteBufferFromHTTP.cpp:472: void std::__function::__policy_invoker::__call_impl[abi:se190107]>(std::__function::__policy_storage const*) @ 0x000000001184cedd 10. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001184858b 11. /build/src/IO/ReadWriteBufferFromHTTP.cpp:465: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x000000001184bf0b 12. /build/src/IO/ReadBuffer.h:60: DB::ReadBuffer::next() @ 0x000000000a148c7b 13. /build/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) @ 0x0000000011849fb2 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]>&)>&, 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&) @ 0x0000000011841980 15. /build/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) @ 0x000000001621208e 16. /build/src/Storages/StorageReplicatedMergeTree.cpp:5228: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl[abi:se190107] const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000015f9a5fe 17. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000015ed8bfd 18. /build/src/Storages/StorageReplicatedMergeTree.cpp:2514: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x0000000015ec9aab 19. /build/src/Storages/StorageReplicatedMergeTree.cpp:2349: DB::StorageReplicatedMergeTree::executeLogEntry(DB::ReplicatedMergeTreeLogEntry&) @ 0x0000000015eba91b 20. /build/src/Storages/StorageReplicatedMergeTree.cpp:3876: bool std::__function::__policy_invoker&)>::__call_impl[abi:se190107])::$_1, bool (std::shared_ptr&)>>(std::__function::__policy_storage const*, std::shared_ptr&) @ 0x0000000015f9837e 21. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000165d6fc3 22. /build/src/Storages/StorageReplicatedMergeTree.cpp:3872: DB::StorageReplicatedMergeTree::processQueueEntry(std::shared_ptr) @ 0x0000000015efc18a 23. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001624c1b2 24. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000162f9c70 25. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x00000000162fa55a 26. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc6653 27. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000000fccc4c3 28. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc3d92 29. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fcca080 30. ? @ 0x00007fbc6213eac3 31. ? @ 0x00007fbc621d0850 (version 25.3.6.10636.altinitytest (altinity build)) 2025.07.28 12:03:06.292490 [ 3974 ] {} test_13.rmt2 (7f9b740d-015c-470e-8cc6-8ba33be0dc63): auto DB::StorageReplicatedMergeTree::processQueueEntry(ReplicatedMergeTreeQueue::SelectedEntryPtr)::(anonymous class)::operator()(LogEntryPtr &) const: Code: 86. DB::HTTPException: Received error from remote server http://146b4357c08d:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Ftest%2F01165%2Ftest_13%2Frmt%2Freplicas%2F1&part=20250728_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.6.10636.altinitytest (altinity build)) '. (RECEIVED_ERROR_FROM_REMOTE_IO_SERVER), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.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 const&, int&&, String const&, unsigned long&&, String const&) @ 0x000000000feda8d9 4. /build/src/IO/HTTPCommon.cpp:104: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x000000000feda6e2 5. /build/src/IO/HTTPCommon.cpp:93: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x000000000feda537 6. /build/src/IO/ReadWriteBufferFromHTTP.cpp:277: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x000000001184a4c4 7. /build/src/IO/ReadWriteBufferFromHTTP.cpp:285: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x000000001184a615 8. /build/src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x000000001184ae59 9. /build/src/IO/ReadWriteBufferFromHTTP.cpp:472: void std::__function::__policy_invoker::__call_impl[abi:se190107]>(std::__function::__policy_storage const*) @ 0x000000001184cedd 10. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001184858b 11. /build/src/IO/ReadWriteBufferFromHTTP.cpp:465: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x000000001184bf0b 12. /build/src/IO/ReadBuffer.h:60: DB::ReadBuffer::next() @ 0x000000000a148c7b 13. /build/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) @ 0x0000000011849fb2 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]>&)>&, 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&) @ 0x0000000011841980 15. /build/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) @ 0x000000001621208e 16. /build/src/Storages/StorageReplicatedMergeTree.cpp:5228: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl[abi:se190107] const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000015f9a5fe 17. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000015ed8bfd 18. /build/src/Storages/StorageReplicatedMergeTree.cpp:2514: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x0000000015ec9aab 19. /build/src/Storages/StorageReplicatedMergeTree.cpp:2349: DB::StorageReplicatedMergeTree::executeLogEntry(DB::ReplicatedMergeTreeLogEntry&) @ 0x0000000015eba91b 20. /build/src/Storages/StorageReplicatedMergeTree.cpp:3876: bool std::__function::__policy_invoker&)>::__call_impl[abi:se190107])::$_1, bool (std::shared_ptr&)>>(std::__function::__policy_storage const*, std::shared_ptr&) @ 0x0000000015f9837e 21. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000165d6fc3 22. /build/src/Storages/StorageReplicatedMergeTree.cpp:3872: DB::StorageReplicatedMergeTree::processQueueEntry(std::shared_ptr) @ 0x0000000015efc18a 23. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001624c1b2 24. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000162f9c70 25. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x00000000162fa55a 26. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc6653 27. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000000fccc4c3 28. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc3d92 29. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fcca080 30. ? @ 0x00007fbc6213eac3 31. ? @ 0x00007fbc621d0850 (version 25.3.6.10636.altinitytest (altinity build)) 2025.07.28 12:03:06.438552 [ 63425 ] {b7d055b2-091f-45a3-94ac-22e69181e62f} 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.6.10636.altinitytest (altinity build)) (from [::1]:51552) (comment: 03149_analyzer_join_projection_name.sql) (query 9, line 24) (in query: SELECT u.uid, u.name, u.gid, u.gname FROM db_for_dict_03149.users u left join db_for_dict_03149.groups_dict g using gid, gname format PrettyCompactMonoBlock;), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000000a074fcb 4. /build/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) @ 0x00000000149c5c9b 5. /build/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) @ 0x0000000016de9821 6. /build/src/Processors/QueryPlan/Optimizations/optimizeJoin.cpp:251: DB::QueryPlanOptimizations::convertLogicalJoinToPhysical(DB::QueryPlan::Node&, std::list>&, DB::QueryPlanOptimizationSettings const&, std::optional) @ 0x0000000016eb5ce9 7. /build/src/Processors/QueryPlan/Optimizations/optimizeTree.cpp:158: DB::QueryPlanOptimizations::optimizeTreeSecondPass(DB::QueryPlanOptimizationSettings const&, DB::QueryPlan::Node&, std::list>&) @ 0x0000000016ead357 8. /build/src/Processors/QueryPlan/QueryPlan.cpp:487: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x0000000016e0055c 9. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:275: DB::InterpreterSelectQueryAnalyzer::buildQueryPipeline() @ 0x0000000014974614 10. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:242: DB::InterpreterSelectQueryAnalyzer::execute() @ 0x000000001497439e 11. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88dc9 12. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 13. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 14. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 15. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 16. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 17. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 18. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 19. ? @ 0x00007fbc6213eac3 20. ? @ 0x00007fbc621d0850 2025.07.28 12:03:06.444189 [ 63425 ] {} 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. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000000a074fcb 4. /build/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) @ 0x00000000149c5c9b 5. /build/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) @ 0x0000000016de9821 6. /build/src/Processors/QueryPlan/Optimizations/optimizeJoin.cpp:251: DB::QueryPlanOptimizations::convertLogicalJoinToPhysical(DB::QueryPlan::Node&, std::list>&, DB::QueryPlanOptimizationSettings const&, std::optional) @ 0x0000000016eb5ce9 7. /build/src/Processors/QueryPlan/Optimizations/optimizeTree.cpp:158: DB::QueryPlanOptimizations::optimizeTreeSecondPass(DB::QueryPlanOptimizationSettings const&, DB::QueryPlan::Node&, std::list>&) @ 0x0000000016ead357 8. /build/src/Processors/QueryPlan/QueryPlan.cpp:487: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x0000000016e0055c 9. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:275: DB::InterpreterSelectQueryAnalyzer::buildQueryPipeline() @ 0x0000000014974614 10. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:242: DB::InterpreterSelectQueryAnalyzer::execute() @ 0x000000001497439e 11. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88dc9 12. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 13. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 14. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 15. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 16. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 17. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 18. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 19. ? @ 0x00007fbc6213eac3 20. ? @ 0x00007fbc621d0850 2025.07.28 12:03:06.456732 [ 3970 ] {} test_13.rmt2 (7f9b740d-015c-470e-8cc6-8ba33be0dc63): auto DB::StorageReplicatedMergeTree::processQueueEntry(ReplicatedMergeTreeQueue::SelectedEntryPtr)::(anonymous class)::operator()(LogEntryPtr &) const: Code: 86. DB::HTTPException: Received error from remote server http://146b4357c08d:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Ftest%2F01165%2Ftest_13%2Frmt%2Freplicas%2F1&part=20250728_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.6.10636.altinitytest (altinity build)) '. (RECEIVED_ERROR_FROM_REMOTE_IO_SERVER), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.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 const&, int&&, String const&, unsigned long&&, String const&) @ 0x000000000feda8d9 4. /build/src/IO/HTTPCommon.cpp:104: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x000000000feda6e2 5. /build/src/IO/HTTPCommon.cpp:93: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x000000000feda537 6. /build/src/IO/ReadWriteBufferFromHTTP.cpp:277: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x000000001184a4c4 7. /build/src/IO/ReadWriteBufferFromHTTP.cpp:285: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x000000001184a615 8. /build/src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x000000001184ae59 9. /build/src/IO/ReadWriteBufferFromHTTP.cpp:472: void std::__function::__policy_invoker::__call_impl[abi:se190107]>(std::__function::__policy_storage const*) @ 0x000000001184cedd 10. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001184858b 11. /build/src/IO/ReadWriteBufferFromHTTP.cpp:465: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x000000001184bf0b 12. /build/src/IO/ReadBuffer.h:60: DB::ReadBuffer::next() @ 0x000000000a148c7b 13. /build/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) @ 0x0000000011849fb2 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]>&)>&, 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&) @ 0x0000000011841980 15. /build/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) @ 0x000000001621208e 16. /build/src/Storages/StorageReplicatedMergeTree.cpp:5228: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl[abi:se190107] const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000015f9a5fe 17. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000015ed8bfd 18. /build/src/Storages/StorageReplicatedMergeTree.cpp:2514: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x0000000015ec9aab 19. /build/src/Storages/StorageReplicatedMergeTree.cpp:2349: DB::StorageReplicatedMergeTree::executeLogEntry(DB::ReplicatedMergeTreeLogEntry&) @ 0x0000000015eba91b 20. /build/src/Storages/StorageReplicatedMergeTree.cpp:3876: bool std::__function::__policy_invoker&)>::__call_impl[abi:se190107])::$_1, bool (std::shared_ptr&)>>(std::__function::__policy_storage const*, std::shared_ptr&) @ 0x0000000015f9837e 21. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000165d6fc3 22. /build/src/Storages/StorageReplicatedMergeTree.cpp:3872: DB::StorageReplicatedMergeTree::processQueueEntry(std::shared_ptr) @ 0x0000000015efc18a 23. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001624c1b2 24. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000162f9c70 25. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x00000000162fa55a 26. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc6653 27. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000000fccc4c3 28. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc3d92 29. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fcca080 30. ? @ 0x00007fbc6213eac3 31. ? @ 0x00007fbc621d0850 (version 25.3.6.10636.altinitytest (altinity build)) 2025.07.28 12:03:06.720747 [ 3971 ] {} test_13.rmt2 (7f9b740d-015c-470e-8cc6-8ba33be0dc63): auto DB::StorageReplicatedMergeTree::processQueueEntry(ReplicatedMergeTreeQueue::SelectedEntryPtr)::(anonymous class)::operator()(LogEntryPtr &) const: Code: 86. DB::HTTPException: Received error from remote server http://146b4357c08d:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Ftest%2F01165%2Ftest_13%2Frmt%2Freplicas%2F1&part=20250728_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.6.10636.altinitytest (altinity build)) '. (RECEIVED_ERROR_FROM_REMOTE_IO_SERVER), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.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 const&, int&&, String const&, unsigned long&&, String const&) @ 0x000000000feda8d9 4. /build/src/IO/HTTPCommon.cpp:104: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x000000000feda6e2 5. /build/src/IO/HTTPCommon.cpp:93: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x000000000feda537 6. /build/src/IO/ReadWriteBufferFromHTTP.cpp:277: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x000000001184a4c4 7. /build/src/IO/ReadWriteBufferFromHTTP.cpp:285: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x000000001184a615 8. /build/src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x000000001184ae59 9. /build/src/IO/ReadWriteBufferFromHTTP.cpp:472: void std::__function::__policy_invoker::__call_impl[abi:se190107]>(std::__function::__policy_storage const*) @ 0x000000001184cedd 10. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001184858b 11. /build/src/IO/ReadWriteBufferFromHTTP.cpp:465: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x000000001184bf0b 12. /build/src/IO/ReadBuffer.h:60: DB::ReadBuffer::next() @ 0x000000000a148c7b 13. /build/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) @ 0x0000000011849fb2 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]>&)>&, 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&) @ 0x0000000011841980 15. /build/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) @ 0x000000001621208e 16. /build/src/Storages/StorageReplicatedMergeTree.cpp:5228: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl[abi:se190107] const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000015f9a5fe 17. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000015ed8bfd 18. /build/src/Storages/StorageReplicatedMergeTree.cpp:2514: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x0000000015ec9aab 19. /build/src/Storages/StorageReplicatedMergeTree.cpp:2349: DB::StorageReplicatedMergeTree::executeLogEntry(DB::ReplicatedMergeTreeLogEntry&) @ 0x0000000015eba91b 20. /build/src/Storages/StorageReplicatedMergeTree.cpp:3876: bool std::__function::__policy_invoker&)>::__call_impl[abi:se190107])::$_1, bool (std::shared_ptr&)>>(std::__function::__policy_storage const*, std::shared_ptr&) @ 0x0000000015f9837e 21. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000165d6fc3 22. /build/src/Storages/StorageReplicatedMergeTree.cpp:3872: DB::StorageReplicatedMergeTree::processQueueEntry(std::shared_ptr) @ 0x0000000015efc18a 23. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001624c1b2 24. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000162f9c70 25. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x00000000162fa55a 26. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc6653 27. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000000fccc4c3 28. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc3d92 29. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fcca080 30. ? @ 0x00007fbc6213eac3 31. ? @ 0x00007fbc621d0850 (version 25.3.6.10636.altinitytest (altinity build)) 2025.07.28 12:03:06.804326 [ 3965 ] {} test_13.rmt2 (7f9b740d-015c-470e-8cc6-8ba33be0dc63): auto DB::StorageReplicatedMergeTree::processQueueEntry(ReplicatedMergeTreeQueue::SelectedEntryPtr)::(anonymous class)::operator()(LogEntryPtr &) const: Code: 86. DB::HTTPException: Received error from remote server http://146b4357c08d:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Ftest%2F01165%2Ftest_13%2Frmt%2Freplicas%2F1&part=20250728_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.6.10636.altinitytest (altinity build)) '. (RECEIVED_ERROR_FROM_REMOTE_IO_SERVER), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.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 const&, int&&, String const&, unsigned long&&, String const&) @ 0x000000000feda8d9 4. /build/src/IO/HTTPCommon.cpp:104: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x000000000feda6e2 5. /build/src/IO/HTTPCommon.cpp:93: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x000000000feda537 6. /build/src/IO/ReadWriteBufferFromHTTP.cpp:277: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x000000001184a4c4 7. /build/src/IO/ReadWriteBufferFromHTTP.cpp:285: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x000000001184a615 8. /build/src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x000000001184ae59 9. /build/src/IO/ReadWriteBufferFromHTTP.cpp:472: void std::__function::__policy_invoker::__call_impl[abi:se190107]>(std::__function::__policy_storage const*) @ 0x000000001184cedd 10. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001184858b 11. /build/src/IO/ReadWriteBufferFromHTTP.cpp:465: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x000000001184bf0b 12. /build/src/IO/ReadBuffer.h:60: DB::ReadBuffer::next() @ 0x000000000a148c7b 13. /build/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) @ 0x0000000011849fb2 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]>&)>&, 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&) @ 0x0000000011841980 15. /build/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) @ 0x000000001621208e 16. /build/src/Storages/StorageReplicatedMergeTree.cpp:5228: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl[abi:se190107] const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000015f9a5fe 17. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000015ed8bfd 18. /build/src/Storages/StorageReplicatedMergeTree.cpp:2514: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x0000000015ec9aab 19. /build/src/Storages/StorageReplicatedMergeTree.cpp:2349: DB::StorageReplicatedMergeTree::executeLogEntry(DB::ReplicatedMergeTreeLogEntry&) @ 0x0000000015eba91b 20. /build/src/Storages/StorageReplicatedMergeTree.cpp:3876: bool std::__function::__policy_invoker&)>::__call_impl[abi:se190107])::$_1, bool (std::shared_ptr&)>>(std::__function::__policy_storage const*, std::shared_ptr&) @ 0x0000000015f9837e 21. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000165d6fc3 22. /build/src/Storages/StorageReplicatedMergeTree.cpp:3872: DB::StorageReplicatedMergeTree::processQueueEntry(std::shared_ptr) @ 0x0000000015efc18a 23. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001624c1b2 24. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000162f9c70 25. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x00000000162fa55a 26. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc6653 27. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000000fccc4c3 28. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc3d92 29. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fcca080 30. ? @ 0x00007fbc6213eac3 31. ? @ 0x00007fbc621d0850 (version 25.3.6.10636.altinitytest (altinity build)) 2025.07.28 12:03:07.290953 [ 62093 ] {fe8dcf73-c59b-45f0-a77e-f42d75224fb9} executeQuery: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=50, jobs=0): (while reading column json.a.:`Array(JSON)`): (while reading from part /var/lib/clickhouse/store/554/554e4bab-dac2-4895-9c72-3e60d8303018/all_1_3_2/ in table test_5eshng7o.test (554e4bab-dac2-4895-9c72-3e60d8303018) located on disk default of type local, from mark 0 with max_rows_to_read = 15): While executing MergeTreeSelect(pool: ReadPoolInOrder, algorithm: InOrder). (CANNOT_SCHEDULE_TASK) (version 25.3.6.10636.altinitytest (altinity build)) (from [::1]:59504) (comment: 03223_nested_json_in_shared_data_merges.sql) (query 20, line 24) (in query: select JSONSharedDataPaths(arrayJoin(json.a[])) from test;), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000fccaeeb 4. /build/src/Common/ThreadPool.cpp:275: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000fccc813 5. /build/src/Common/ThreadPool.cpp:323: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fcc7bbc 6. /build/src/Common/ThreadPool.cpp:494: ThreadPoolImpl>::scheduleOrThrowOnError(std::function, Priority) @ 0x000000000fcc7a0e 7. /build/src/Common/threadPoolCallbackRunner.h:52: std::future> std::__function::__policy_invoker> (DB::MergeTreeMarksLoader::loadMarksAsync()::$_0&&, Priority)>::__call_impl[abi:se190107]> (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&&) @ 0x0000000016474731 8. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000016471940 9. /build/src/Storages/MergeTree/MergeTreeMarksLoader.cpp:83: DB::MergeTreeMarksLoader::startAsyncLoad() @ 0x000000001647173f 10. /build/src/Storages/MergeTree/MergeTreeReaderWide.cpp:294: DB::MergeTreeReaderWide::addStream(DB::ISerialization::SubstreamPath const&, String const&) @ 0x00000000164aa163 11. /build/src/Storages/MergeTree/MergeTreeReaderWide.cpp:323: 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>>>&) @ 0x00000000164aa642 12. /build/src/Storages/MergeTree/MergeTreeReaderWide.cpp:516: DB::ReadBuffer* std::__function::__policy_invoker::__call_impl[abi:se190107] 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&) @ 0x00000000164abe68 13. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000013c7b611 14. /build/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 @ 0x0000000013ccbd7f 15. /build/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 @ 0x0000000013d2166e 16. /build/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 @ 0x0000000013c84e1b 17. /build/src/DataTypes/Serializations/SerializationObject.cpp:795: DB::SerializationObject::deserializeBinaryBulkWithMultipleStreams(COW::immutable_ptr&, unsigned long, DB::ISerialization::DeserializeBinaryBulkSettings&, std::shared_ptr&, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>*) const @ 0x0000000013cf09c0 18. /build/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 @ 0x0000000013c84e1b 19. /build/src/DataTypes/Serializations/SerializationVariantElement.cpp:201: DB::SerializationVariantElement::deserializeBinaryBulkWithMultipleStreams(COW::immutable_ptr&, unsigned long, DB::ISerialization::DeserializeBinaryBulkSettings&, std::shared_ptr&, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>*) const @ 0x0000000013d3d6b3 20. /build/src/DataTypes/Serializations/SerializationDynamicElement.cpp:154: DB::SerializationDynamicElement::deserializeBinaryBulkWithMultipleStreams(COW::immutable_ptr&, unsigned long, DB::ISerialization::DeserializeBinaryBulkSettings&, std::shared_ptr&, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>*) const @ 0x0000000013ca80c3 21. /build/src/DataTypes/Serializations/SerializationObjectDynamicPath.cpp:154: DB::SerializationObjectDynamicPath::deserializeBinaryBulkWithMultipleStreams(COW::immutable_ptr&, unsigned long, DB::ISerialization::DeserializeBinaryBulkSettings&, std::shared_ptr&, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>*) const @ 0x0000000013d0d3cc 22. /build/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>>>&) @ 0x00000000164a9d8e 23. /build/src/Storages/MergeTree/MergeTreeReaderWide.cpp:172: DB::MergeTreeReaderWide::readRows(unsigned long, unsigned long, bool, unsigned long, std::vector::immutable_ptr, std::allocator::immutable_ptr>>&) @ 0x00000000164a94d2 24. /build/src/Storages/MergeTree/MergeTreeRangeReader.cpp:116: DB::MergeTreeRangeReader::DelayedStream::finalize(std::vector::immutable_ptr, std::allocator::immutable_ptr>>&) @ 0x0000000016497db1 25. /build/src/Storages/MergeTree/MergeTreeRangeReader.cpp:298: DB::MergeTreeRangeReader::startReadingChain(unsigned long, DB::MarkRanges&) @ 0x000000001649f129 26. /build/src/Storages/MergeTree/MergeTreeReadersChain.cpp:67: DB::MergeTreeReadersChain::read(unsigned long, DB::MarkRanges&) @ 0x00000000164b9dda 27. /build/src/Storages/MergeTree/MergeTreeReadTask.cpp:172: DB::MergeTreeReadTask::read() @ 0x00000000164b6300 28. /build/src/Storages/MergeTree/MergeTreeSelectAlgorithms.h:53: DB::MergeTreeInOrderSelectAlgorithm::readFromTask(DB::MergeTreeReadTask&) @ 0x0000000016e56d4c 29. /build/src/Storages/MergeTree/MergeTreeSelectProcessor.cpp:207: DB::MergeTreeSelectProcessor::read() @ 0x00000000164c0ba4 30. /build/src/Storages/MergeTree/MergeTreeSource.cpp:229: DB::MergeTreeSource::tryGenerate() @ 0x0000000016e43d69 31. /build/src/Processors/ISource.cpp:108: DB::ISource::work() @ 0x00000000169a21e7 2025.07.28 12:03:07.332616 [ 62093 ] {} TCPHandler: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=50, jobs=0): (while reading column json.a.:`Array(JSON)`): (while reading from part /var/lib/clickhouse/store/554/554e4bab-dac2-4895-9c72-3e60d8303018/all_1_3_2/ in table test_5eshng7o.test (554e4bab-dac2-4895-9c72-3e60d8303018) located on disk default of type local, from mark 0 with max_rows_to_read = 15): While executing MergeTreeSelect(pool: ReadPoolInOrder, algorithm: InOrder). (CANNOT_SCHEDULE_TASK), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000fccaeeb 4. /build/src/Common/ThreadPool.cpp:275: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000fccc813 5. /build/src/Common/ThreadPool.cpp:323: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fcc7bbc 6. /build/src/Common/ThreadPool.cpp:494: ThreadPoolImpl>::scheduleOrThrowOnError(std::function, Priority) @ 0x000000000fcc7a0e 7. /build/src/Common/threadPoolCallbackRunner.h:52: std::future> std::__function::__policy_invoker> (DB::MergeTreeMarksLoader::loadMarksAsync()::$_0&&, Priority)>::__call_impl[abi:se190107]> (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&&) @ 0x0000000016474731 8. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000016471940 9. /build/src/Storages/MergeTree/MergeTreeMarksLoader.cpp:83: DB::MergeTreeMarksLoader::startAsyncLoad() @ 0x000000001647173f 10. /build/src/Storages/MergeTree/MergeTreeReaderWide.cpp:294: DB::MergeTreeReaderWide::addStream(DB::ISerialization::SubstreamPath const&, String const&) @ 0x00000000164aa163 11. /build/src/Storages/MergeTree/MergeTreeReaderWide.cpp:323: 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>>>&) @ 0x00000000164aa642 12. /build/src/Storages/MergeTree/MergeTreeReaderWide.cpp:516: DB::ReadBuffer* std::__function::__policy_invoker::__call_impl[abi:se190107] 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&) @ 0x00000000164abe68 13. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000013c7b611 14. /build/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 @ 0x0000000013ccbd7f 15. /build/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 @ 0x0000000013d2166e 16. /build/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 @ 0x0000000013c84e1b 17. /build/src/DataTypes/Serializations/SerializationObject.cpp:795: DB::SerializationObject::deserializeBinaryBulkWithMultipleStreams(COW::immutable_ptr&, unsigned long, DB::ISerialization::DeserializeBinaryBulkSettings&, std::shared_ptr&, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>*) const @ 0x0000000013cf09c0 18. /build/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 @ 0x0000000013c84e1b 19. /build/src/DataTypes/Serializations/SerializationVariantElement.cpp:201: DB::SerializationVariantElement::deserializeBinaryBulkWithMultipleStreams(COW::immutable_ptr&, unsigned long, DB::ISerialization::DeserializeBinaryBulkSettings&, std::shared_ptr&, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>*) const @ 0x0000000013d3d6b3 20. /build/src/DataTypes/Serializations/SerializationDynamicElement.cpp:154: DB::SerializationDynamicElement::deserializeBinaryBulkWithMultipleStreams(COW::immutable_ptr&, unsigned long, DB::ISerialization::DeserializeBinaryBulkSettings&, std::shared_ptr&, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>*) const @ 0x0000000013ca80c3 21. /build/src/DataTypes/Serializations/SerializationObjectDynamicPath.cpp:154: DB::SerializationObjectDynamicPath::deserializeBinaryBulkWithMultipleStreams(COW::immutable_ptr&, unsigned long, DB::ISerialization::DeserializeBinaryBulkSettings&, std::shared_ptr&, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>*) const @ 0x0000000013d0d3cc 22. /build/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>>>&) @ 0x00000000164a9d8e 23. /build/src/Storages/MergeTree/MergeTreeReaderWide.cpp:172: DB::MergeTreeReaderWide::readRows(unsigned long, unsigned long, bool, unsigned long, std::vector::immutable_ptr, std::allocator::immutable_ptr>>&) @ 0x00000000164a94d2 24. /build/src/Storages/MergeTree/MergeTreeRangeReader.cpp:116: DB::MergeTreeRangeReader::DelayedStream::finalize(std::vector::immutable_ptr, std::allocator::immutable_ptr>>&) @ 0x0000000016497db1 25. /build/src/Storages/MergeTree/MergeTreeRangeReader.cpp:298: DB::MergeTreeRangeReader::startReadingChain(unsigned long, DB::MarkRanges&) @ 0x000000001649f129 26. /build/src/Storages/MergeTree/MergeTreeReadersChain.cpp:67: DB::MergeTreeReadersChain::read(unsigned long, DB::MarkRanges&) @ 0x00000000164b9dda 27. /build/src/Storages/MergeTree/MergeTreeReadTask.cpp:172: DB::MergeTreeReadTask::read() @ 0x00000000164b6300 28. /build/src/Storages/MergeTree/MergeTreeSelectAlgorithms.h:53: DB::MergeTreeInOrderSelectAlgorithm::readFromTask(DB::MergeTreeReadTask&) @ 0x0000000016e56d4c 29. /build/src/Storages/MergeTree/MergeTreeSelectProcessor.cpp:207: DB::MergeTreeSelectProcessor::read() @ 0x00000000164c0ba4 30. /build/src/Storages/MergeTree/MergeTreeSource.cpp:229: DB::MergeTreeSource::tryGenerate() @ 0x0000000016e43d69 31. /build/src/Processors/ISource.cpp:108: DB::ISource::work() @ 0x00000000169a21e7 Job's origin stack trace: 0. /build/src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000000fc33b84 1. /build/src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000000fcc2ea7 2. /build/src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fcc535c 3. /build/src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000000fcc584d 4. /build/src/Common/ThreadPool.h:279: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x00000000169bf193 5. /build/src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x00000000169bf518 6. /build/src/Server/TCPHandler.cpp:1237: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x00000000168f1525 7. /build/src/Server/TCPHandler.cpp:678: DB::TCPHandler::runImpl() @ 0x00000000168e68e5 8. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 9. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 10. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 11. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 12. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 13. ? @ 0x00007fbc6213eac3 14. ? @ 0x00007fbc621d0850 2025.07.28 12:03:07.398723 [ 3969 ] {} test_13.rmt2 (7f9b740d-015c-470e-8cc6-8ba33be0dc63): auto DB::StorageReplicatedMergeTree::processQueueEntry(ReplicatedMergeTreeQueue::SelectedEntryPtr)::(anonymous class)::operator()(LogEntryPtr &) const: Code: 86. DB::HTTPException: Received error from remote server http://146b4357c08d:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Ftest%2F01165%2Ftest_13%2Frmt%2Freplicas%2F1&part=20250728_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.6.10636.altinitytest (altinity build)) '. (RECEIVED_ERROR_FROM_REMOTE_IO_SERVER), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.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 const&, int&&, String const&, unsigned long&&, String const&) @ 0x000000000feda8d9 4. /build/src/IO/HTTPCommon.cpp:104: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x000000000feda6e2 5. /build/src/IO/HTTPCommon.cpp:93: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x000000000feda537 6. /build/src/IO/ReadWriteBufferFromHTTP.cpp:277: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x000000001184a4c4 7. /build/src/IO/ReadWriteBufferFromHTTP.cpp:285: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x000000001184a615 8. /build/src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x000000001184ae59 9. /build/src/IO/ReadWriteBufferFromHTTP.cpp:472: void std::__function::__policy_invoker::__call_impl[abi:se190107]>(std::__function::__policy_storage const*) @ 0x000000001184cedd 10. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001184858b 11. /build/src/IO/ReadWriteBufferFromHTTP.cpp:465: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x000000001184bf0b 12. /build/src/IO/ReadBuffer.h:60: DB::ReadBuffer::next() @ 0x000000000a148c7b 13. /build/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) @ 0x0000000011849fb2 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]>&)>&, 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&) @ 0x0000000011841980 15. /build/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) @ 0x000000001621208e 16. /build/src/Storages/StorageReplicatedMergeTree.cpp:5228: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl[abi:se190107] const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000015f9a5fe 17. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000015ed8bfd 18. /build/src/Storages/StorageReplicatedMergeTree.cpp:2514: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x0000000015ec9aab 19. /build/src/Storages/StorageReplicatedMergeTree.cpp:2349: DB::StorageReplicatedMergeTree::executeLogEntry(DB::ReplicatedMergeTreeLogEntry&) @ 0x0000000015eba91b 20. /build/src/Storages/StorageReplicatedMergeTree.cpp:3876: bool std::__function::__policy_invoker&)>::__call_impl[abi:se190107])::$_1, bool (std::shared_ptr&)>>(std::__function::__policy_storage const*, std::shared_ptr&) @ 0x0000000015f9837e 21. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000165d6fc3 22. /build/src/Storages/StorageReplicatedMergeTree.cpp:3872: DB::StorageReplicatedMergeTree::processQueueEntry(std::shared_ptr) @ 0x0000000015efc18a 23. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001624c1b2 24. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000162f9c70 25. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x00000000162fa55a 26. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc6653 27. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000000fccc4c3 28. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc3d92 29. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fcca080 30. ? @ 0x00007fbc6213eac3 31. ? @ 0x00007fbc621d0850 (version 25.3.6.10636.altinitytest (altinity build)) 2025.07.28 12:03:07.434232 [ 5747 ] {292bdf2f-3d34-4acf-9d55-093778abe1c1} executeQuery: Code: 219. DB::Exception: New table appeared in database being dropped or detached. Try again. (DATABASE_NOT_EMPTY) (version 25.3.6.10636.altinitytest (altinity build)) (from [::1]:34914) (comment: 03223_nested_json_in_shared_data_merges.sql) (in query: DROP DATABASE IF EXISTS test_5eshng7o SYNC ), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000000a074fcb 4. /build/src/Interpreters/DatabaseCatalog.cpp:608: DB::DatabaseCatalog::detachDatabase(std::shared_ptr, String const&, bool, bool) @ 0x00000000144f41b9 5. /build/src/Interpreters/InterpreterDropQuery.cpp:482: DB::InterpreterDropQuery::executeToDatabaseImpl(DB::ASTDropQuery const&, std::shared_ptr&, std::vector, DB::UUIDTag>, std::allocator, DB::UUIDTag>>>&) @ 0x00000000149179be 6. /build/src/Interpreters/InterpreterDropQuery.cpp:363: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x0000000014913988 7. /build/src/Interpreters/InterpreterDropQuery.cpp:99: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000014913142 8. /build/src/Interpreters/InterpreterDropQuery.cpp:72: DB::InterpreterDropQuery::execute() @ 0x0000000014912b65 9. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88dc9 10. /build/src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x0000000014c8ca7b 11. /build/src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000001686da12 12. /build/src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x0000000016870807 13. /build/src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x0000000016907e99 14. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 15. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 16. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 17. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 18. ? @ 0x00007fbc6213eac3 19. ? @ 0x00007fbc621d0850 2025.07.28 12:03:07.446065 [ 5747 ] {292bdf2f-3d34-4acf-9d55-093778abe1c1} 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. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000000a074fcb 4. /build/src/Interpreters/DatabaseCatalog.cpp:608: DB::DatabaseCatalog::detachDatabase(std::shared_ptr, String const&, bool, bool) @ 0x00000000144f41b9 5. /build/src/Interpreters/InterpreterDropQuery.cpp:482: DB::InterpreterDropQuery::executeToDatabaseImpl(DB::ASTDropQuery const&, std::shared_ptr&, std::vector, DB::UUIDTag>, std::allocator, DB::UUIDTag>>>&) @ 0x00000000149179be 6. /build/src/Interpreters/InterpreterDropQuery.cpp:363: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x0000000014913988 7. /build/src/Interpreters/InterpreterDropQuery.cpp:99: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000014913142 8. /build/src/Interpreters/InterpreterDropQuery.cpp:72: DB::InterpreterDropQuery::execute() @ 0x0000000014912b65 9. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88dc9 10. /build/src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x0000000014c8ca7b 11. /build/src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000001686da12 12. /build/src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x0000000016870807 13. /build/src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x0000000016907e99 14. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 15. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 16. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 17. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 18. ? @ 0x00007fbc6213eac3 19. ? @ 0x00007fbc621d0850 (version 25.3.6.10636.altinitytest (altinity build)) 2025.07.28 12:03:07.535200 [ 3964 ] {} test_13.rmt2 (7f9b740d-015c-470e-8cc6-8ba33be0dc63): auto DB::StorageReplicatedMergeTree::processQueueEntry(ReplicatedMergeTreeQueue::SelectedEntryPtr)::(anonymous class)::operator()(LogEntryPtr &) const: Code: 86. DB::HTTPException: Received error from remote server http://146b4357c08d:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Ftest%2F01165%2Ftest_13%2Frmt%2Freplicas%2F1&part=20250728_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.6.10636.altinitytest (altinity build)) '. (RECEIVED_ERROR_FROM_REMOTE_IO_SERVER), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.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 const&, int&&, String const&, unsigned long&&, String const&) @ 0x000000000feda8d9 4. /build/src/IO/HTTPCommon.cpp:104: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x000000000feda6e2 5. /build/src/IO/HTTPCommon.cpp:93: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x000000000feda537 6. /build/src/IO/ReadWriteBufferFromHTTP.cpp:277: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x000000001184a4c4 7. /build/src/IO/ReadWriteBufferFromHTTP.cpp:285: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x000000001184a615 8. /build/src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x000000001184ae59 9. /build/src/IO/ReadWriteBufferFromHTTP.cpp:472: void std::__function::__policy_invoker::__call_impl[abi:se190107]>(std::__function::__policy_storage const*) @ 0x000000001184cedd 10. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001184858b 11. /build/src/IO/ReadWriteBufferFromHTTP.cpp:465: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x000000001184bf0b 12. /build/src/IO/ReadBuffer.h:60: DB::ReadBuffer::next() @ 0x000000000a148c7b 13. /build/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) @ 0x0000000011849fb2 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]>&)>&, 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&) @ 0x0000000011841980 15. /build/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) @ 0x000000001621208e 16. /build/src/Storages/StorageReplicatedMergeTree.cpp:5228: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl[abi:se190107] const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000015f9a5fe 17. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000015ed8bfd 18. /build/src/Storages/StorageReplicatedMergeTree.cpp:2514: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x0000000015ec9aab 19. /build/src/Storages/StorageReplicatedMergeTree.cpp:2349: DB::StorageReplicatedMergeTree::executeLogEntry(DB::ReplicatedMergeTreeLogEntry&) @ 0x0000000015eba91b 20. /build/src/Storages/StorageReplicatedMergeTree.cpp:3876: bool std::__function::__policy_invoker&)>::__call_impl[abi:se190107])::$_1, bool (std::shared_ptr&)>>(std::__function::__policy_storage const*, std::shared_ptr&) @ 0x0000000015f9837e 21. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000165d6fc3 22. /build/src/Storages/StorageReplicatedMergeTree.cpp:3872: DB::StorageReplicatedMergeTree::processQueueEntry(std::shared_ptr) @ 0x0000000015efc18a 23. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001624c1b2 24. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000162f9c70 25. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x00000000162fa55a 26. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc6653 27. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000000fccc4c3 28. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc3d92 29. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fcca080 30. ? @ 0x00007fbc6213eac3 31. ? @ 0x00007fbc621d0850 (version 25.3.6.10636.altinitytest (altinity build)) 2025.07.28 12:03:08.293441 [ 3977 ] {} test_13.rmt2 (7f9b740d-015c-470e-8cc6-8ba33be0dc63): auto DB::StorageReplicatedMergeTree::processQueueEntry(ReplicatedMergeTreeQueue::SelectedEntryPtr)::(anonymous class)::operator()(LogEntryPtr &) const: Code: 86. DB::HTTPException: Received error from remote server http://146b4357c08d:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Ftest%2F01165%2Ftest_13%2Frmt%2Freplicas%2F1&part=20250728_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.6.10636.altinitytest (altinity build)) '. (RECEIVED_ERROR_FROM_REMOTE_IO_SERVER), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.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 const&, int&&, String const&, unsigned long&&, String const&) @ 0x000000000feda8d9 4. /build/src/IO/HTTPCommon.cpp:104: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x000000000feda6e2 5. /build/src/IO/HTTPCommon.cpp:93: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x000000000feda537 6. /build/src/IO/ReadWriteBufferFromHTTP.cpp:277: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x000000001184a4c4 7. /build/src/IO/ReadWriteBufferFromHTTP.cpp:285: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x000000001184a615 8. /build/src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x000000001184ae59 9. /build/src/IO/ReadWriteBufferFromHTTP.cpp:472: void std::__function::__policy_invoker::__call_impl[abi:se190107]>(std::__function::__policy_storage const*) @ 0x000000001184cedd 10. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001184858b 11. /build/src/IO/ReadWriteBufferFromHTTP.cpp:465: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x000000001184bf0b 12. /build/src/IO/ReadBuffer.h:60: DB::ReadBuffer::next() @ 0x000000000a148c7b 13. /build/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) @ 0x0000000011849fb2 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]>&)>&, 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&) @ 0x0000000011841980 15. /build/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) @ 0x000000001621208e 16. /build/src/Storages/StorageReplicatedMergeTree.cpp:5228: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl[abi:se190107] const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000015f9a5fe 17. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000015ed8bfd 18. /build/src/Storages/StorageReplicatedMergeTree.cpp:2514: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x0000000015ec9aab 19. /build/src/Storages/StorageReplicatedMergeTree.cpp:2349: DB::StorageReplicatedMergeTree::executeLogEntry(DB::ReplicatedMergeTreeLogEntry&) @ 0x0000000015eba91b 20. /build/src/Storages/StorageReplicatedMergeTree.cpp:3876: bool std::__function::__policy_invoker&)>::__call_impl[abi:se190107])::$_1, bool (std::shared_ptr&)>>(std::__function::__policy_storage const*, std::shared_ptr&) @ 0x0000000015f9837e 21. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000165d6fc3 22. /build/src/Storages/StorageReplicatedMergeTree.cpp:3872: DB::StorageReplicatedMergeTree::processQueueEntry(std::shared_ptr) @ 0x0000000015efc18a 23. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001624c1b2 24. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000162f9c70 25. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x00000000162fa55a 26. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc6653 27. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000000fccc4c3 28. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc3d92 29. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fcca080 30. ? @ 0x00007fbc6213eac3 31. ? @ 0x00007fbc621d0850 (version 25.3.6.10636.altinitytest (altinity build)) 2025.07.28 12:03:08.561770 [ 62056 ] {bdc23fb4-f62a-41d2-ae30-812ded7b5211} executeQuery: Code: 43. DB::Exception: Datetime argument and origin argument for function toStartOfInterval must have the same type: In scope SELECT toStartOfInterval(toDate('2023-01-02 14:45:50'), toIntervalSecond(5), toDate32('2023-01-02 14:44:30')). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.6.10636.altinitytest (altinity build)) (from [::1]:51712) (comment: 02916_to_start_of_interval_with_origin.sql) (query 3, line 5) (in query: -- time and origin arguments must have the same type SELECT toStartOfInterval(toDate('2023-01-02 14:45:50'), toIntervalSecond(5), toDate32('2023-01-02 14:44:30'));), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x000000000a06b56b 4. /build/src/Functions/toStartOfInterval.cpp:134: DB::FunctionToStartOfInterval::getReturnTypeImpl(std::vector> const&) const::'lambda1'()::operator()() const @ 0x000000000e8bab81 5. /build/src/Functions/toStartOfInterval.cpp:169: DB::FunctionToStartOfInterval::getReturnTypeImpl(std::vector> const&) const @ 0x000000000e884ac4 6. /build/src/Functions/IFunction.cpp:645: DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x0000000012d96b0c 7. /build/src/Functions/IFunction.cpp:577: DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x0000000012d9669c 8. /build/src/Functions/IFunction.cpp:606: DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x0000000012d96edc 9. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3544: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000014033cc9 10. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3838: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000014019a9e 11. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3980: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000014018e31 12. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:4304: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000014042fa7 13. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5605: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000014013749 14. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000140127f9 15. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000014011fce 16. /build/src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000001406ce8a 17. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000014973b42 18. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000001497268d 19. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000014974d24 20. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001492924b 21. /build/src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88641 22. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 23. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 24. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 25. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 26. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 27. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 28. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 29. ? @ 0x00007fbc6213eac3 30. ? @ 0x00007fbc621d0850 2025.07.28 12:03:08.600045 [ 62056 ] {} TCPHandler: Code: 43. DB::Exception: Datetime argument and origin argument for function toStartOfInterval must have the same type: In scope SELECT toStartOfInterval(toDate('2023-01-02 14:45:50'), toIntervalSecond(5), toDate32('2023-01-02 14:44:30')). (ILLEGAL_TYPE_OF_ARGUMENT), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x000000000a06b56b 4. /build/src/Functions/toStartOfInterval.cpp:134: DB::FunctionToStartOfInterval::getReturnTypeImpl(std::vector> const&) const::'lambda1'()::operator()() const @ 0x000000000e8bab81 5. /build/src/Functions/toStartOfInterval.cpp:169: DB::FunctionToStartOfInterval::getReturnTypeImpl(std::vector> const&) const @ 0x000000000e884ac4 6. /build/src/Functions/IFunction.cpp:645: DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x0000000012d96b0c 7. /build/src/Functions/IFunction.cpp:577: DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x0000000012d9669c 8. /build/src/Functions/IFunction.cpp:606: DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x0000000012d96edc 9. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3544: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000014033cc9 10. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3838: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000014019a9e 11. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3980: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000014018e31 12. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:4304: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000014042fa7 13. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5605: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000014013749 14. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000140127f9 15. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000014011fce 16. /build/src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000001406ce8a 17. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000014973b42 18. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000001497268d 19. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000014974d24 20. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001492924b 21. /build/src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88641 22. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 23. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 24. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 25. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 26. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 27. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 28. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 29. ? @ 0x00007fbc6213eac3 30. ? @ 0x00007fbc621d0850 2025.07.28 12:03:08.726647 [ 62056 ] {463b675e-7eab-46d8-b0f3-fc2a3f5a6322} executeQuery: Code: 43. DB::Exception: Datetime argument and origin argument for function toStartOfInterval must have the same type: In scope SELECT toStartOfInterval(toDate('2023-01-02 14:45:50'), toIntervalMillisecond(12), toDateTime('2023-01-02 14:44:30')). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.6.10636.altinitytest (altinity build)) (from [::1]:51712) (comment: 02916_to_start_of_interval_with_origin.sql) (query 4, line 7) (in query: SELECT toStartOfInterval(toDate('2023-01-02 14:45:50'), toIntervalMillisecond(12), toDateTime('2023-01-02 14:44:30'));), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x000000000a06b56b 4. /build/src/Functions/toStartOfInterval.cpp:134: DB::FunctionToStartOfInterval::getReturnTypeImpl(std::vector> const&) const::'lambda1'()::operator()() const @ 0x000000000e8bab81 5. /build/src/Functions/toStartOfInterval.cpp:169: DB::FunctionToStartOfInterval::getReturnTypeImpl(std::vector> const&) const @ 0x000000000e884ac4 6. /build/src/Functions/IFunction.cpp:645: DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x0000000012d96b0c 7. /build/src/Functions/IFunction.cpp:577: DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x0000000012d9669c 8. /build/src/Functions/IFunction.cpp:606: DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x0000000012d96edc 9. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3544: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000014033cc9 10. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3838: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000014019a9e 11. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3980: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000014018e31 12. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:4304: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000014042fa7 13. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5605: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000014013749 14. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000140127f9 15. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000014011fce 16. /build/src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000001406ce8a 17. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000014973b42 18. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000001497268d 19. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000014974d24 20. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001492924b 21. /build/src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88641 22. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 23. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 24. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 25. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 26. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 27. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 28. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 29. ? @ 0x00007fbc6213eac3 30. ? @ 0x00007fbc621d0850 2025.07.28 12:03:08.733312 [ 62056 ] {} TCPHandler: Code: 43. DB::Exception: Datetime argument and origin argument for function toStartOfInterval must have the same type: In scope SELECT toStartOfInterval(toDate('2023-01-02 14:45:50'), toIntervalMillisecond(12), toDateTime('2023-01-02 14:44:30')). (ILLEGAL_TYPE_OF_ARGUMENT), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x000000000a06b56b 4. /build/src/Functions/toStartOfInterval.cpp:134: DB::FunctionToStartOfInterval::getReturnTypeImpl(std::vector> const&) const::'lambda1'()::operator()() const @ 0x000000000e8bab81 5. /build/src/Functions/toStartOfInterval.cpp:169: DB::FunctionToStartOfInterval::getReturnTypeImpl(std::vector> const&) const @ 0x000000000e884ac4 6. /build/src/Functions/IFunction.cpp:645: DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x0000000012d96b0c 7. /build/src/Functions/IFunction.cpp:577: DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x0000000012d9669c 8. /build/src/Functions/IFunction.cpp:606: DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x0000000012d96edc 9. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3544: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000014033cc9 10. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3838: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000014019a9e 11. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3980: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000014018e31 12. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:4304: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000014042fa7 13. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5605: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000014013749 14. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000140127f9 15. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000014011fce 16. /build/src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000001406ce8a 17. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000014973b42 18. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000001497268d 19. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000014974d24 20. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001492924b 21. /build/src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88641 22. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 23. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 24. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 25. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 26. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 27. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 28. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 29. ? @ 0x00007fbc6213eac3 30. ? @ 0x00007fbc621d0850 2025.07.28 12:03:08.814589 [ 62056 ] {275f4930-6177-4719-8cd6-f9fd906c18df} executeQuery: Code: 43. DB::Exception: Datetime argument and origin argument for function toStartOfInterval must have the same type: In scope SELECT toStartOfInterval(toDate32('2023-01-02 14:45:50'), toIntervalHour(5), toDate('2023-01-02 14:44:30')). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.6.10636.altinitytest (altinity build)) (from [::1]:51712) (comment: 02916_to_start_of_interval_with_origin.sql) (query 5, line 8) (in query: SELECT toStartOfInterval(toDate32('2023-01-02 14:45:50'), toIntervalHour(5), toDate('2023-01-02 14:44:30'));), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x000000000a06b56b 4. /build/src/Functions/toStartOfInterval.cpp:134: DB::FunctionToStartOfInterval::getReturnTypeImpl(std::vector> const&) const::'lambda1'()::operator()() const @ 0x000000000e8bab81 5. /build/src/Functions/toStartOfInterval.cpp:169: DB::FunctionToStartOfInterval::getReturnTypeImpl(std::vector> const&) const @ 0x000000000e884ac4 6. /build/src/Functions/IFunction.cpp:645: DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x0000000012d96b0c 7. /build/src/Functions/IFunction.cpp:577: DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x0000000012d9669c 8. /build/src/Functions/IFunction.cpp:606: DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x0000000012d96edc 9. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3544: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000014033cc9 10. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3838: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000014019a9e 11. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3980: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000014018e31 12. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:4304: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000014042fa7 13. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5605: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000014013749 14. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000140127f9 15. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000014011fce 16. /build/src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000001406ce8a 17. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000014973b42 18. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000001497268d 19. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000014974d24 20. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001492924b 21. /build/src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88641 22. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 23. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 24. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 25. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 26. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 27. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 28. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 29. ? @ 0x00007fbc6213eac3 30. ? @ 0x00007fbc621d0850 2025.07.28 12:03:08.821151 [ 62056 ] {} TCPHandler: Code: 43. DB::Exception: Datetime argument and origin argument for function toStartOfInterval must have the same type: In scope SELECT toStartOfInterval(toDate32('2023-01-02 14:45:50'), toIntervalHour(5), toDate('2023-01-02 14:44:30')). (ILLEGAL_TYPE_OF_ARGUMENT), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x000000000a06b56b 4. /build/src/Functions/toStartOfInterval.cpp:134: DB::FunctionToStartOfInterval::getReturnTypeImpl(std::vector> const&) const::'lambda1'()::operator()() const @ 0x000000000e8bab81 5. /build/src/Functions/toStartOfInterval.cpp:169: DB::FunctionToStartOfInterval::getReturnTypeImpl(std::vector> const&) const @ 0x000000000e884ac4 6. /build/src/Functions/IFunction.cpp:645: DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x0000000012d96b0c 7. /build/src/Functions/IFunction.cpp:577: DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x0000000012d9669c 8. /build/src/Functions/IFunction.cpp:606: DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x0000000012d96edc 9. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3544: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000014033cc9 10. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3838: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000014019a9e 11. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3980: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000014018e31 12. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:4304: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000014042fa7 13. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5605: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000014013749 14. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000140127f9 15. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000014011fce 16. /build/src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000001406ce8a 17. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000014973b42 18. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000001497268d 19. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000014974d24 20. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001492924b 21. /build/src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88641 22. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 23. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 24. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 25. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 26. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 27. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 28. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 29. ? @ 0x00007fbc6213eac3 30. ? @ 0x00007fbc621d0850 2025.07.28 12:03:08.901799 [ 62056 ] {aba8457d-e78c-44fd-a72c-eca08f9c23c0} executeQuery: Code: 43. DB::Exception: Datetime argument and origin argument for function toStartOfInterval must have the same type: In scope SELECT toStartOfInterval(toDateTime('2023-01-02 14:45:50'), toIntervalMinute(1), toDateTime64('2023-01-02 14:44:30', 2)). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.6.10636.altinitytest (altinity build)) (from [::1]:51712) (comment: 02916_to_start_of_interval_with_origin.sql) (query 6, line 9) (in query: SELECT toStartOfInterval(toDateTime('2023-01-02 14:45:50'), toIntervalMinute(1), toDateTime64('2023-01-02 14:44:30', 2));), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x000000000a06b56b 4. /build/src/Functions/toStartOfInterval.cpp:134: DB::FunctionToStartOfInterval::getReturnTypeImpl(std::vector> const&) const::'lambda1'()::operator()() const @ 0x000000000e8bab81 5. /build/src/Functions/toStartOfInterval.cpp:169: DB::FunctionToStartOfInterval::getReturnTypeImpl(std::vector> const&) const @ 0x000000000e884ac4 6. /build/src/Functions/IFunction.cpp:645: DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x0000000012d96b0c 7. /build/src/Functions/IFunction.cpp:577: DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x0000000012d9669c 8. /build/src/Functions/IFunction.cpp:606: DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x0000000012d96edc 9. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3544: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000014033cc9 10. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3838: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000014019a9e 11. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3980: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000014018e31 12. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:4304: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000014042fa7 13. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5605: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000014013749 14. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000140127f9 15. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000014011fce 16. /build/src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000001406ce8a 17. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000014973b42 18. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000001497268d 19. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000014974d24 20. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001492924b 21. /build/src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88641 22. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 23. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 24. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 25. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 26. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 27. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 28. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 29. ? @ 0x00007fbc6213eac3 30. ? @ 0x00007fbc621d0850 2025.07.28 12:03:08.909545 [ 62056 ] {} TCPHandler: Code: 43. DB::Exception: Datetime argument and origin argument for function toStartOfInterval must have the same type: In scope SELECT toStartOfInterval(toDateTime('2023-01-02 14:45:50'), toIntervalMinute(1), toDateTime64('2023-01-02 14:44:30', 2)). (ILLEGAL_TYPE_OF_ARGUMENT), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x000000000a06b56b 4. /build/src/Functions/toStartOfInterval.cpp:134: DB::FunctionToStartOfInterval::getReturnTypeImpl(std::vector> const&) const::'lambda1'()::operator()() const @ 0x000000000e8bab81 5. /build/src/Functions/toStartOfInterval.cpp:169: DB::FunctionToStartOfInterval::getReturnTypeImpl(std::vector> const&) const @ 0x000000000e884ac4 6. /build/src/Functions/IFunction.cpp:645: DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x0000000012d96b0c 7. /build/src/Functions/IFunction.cpp:577: DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x0000000012d9669c 8. /build/src/Functions/IFunction.cpp:606: DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x0000000012d96edc 9. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3544: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000014033cc9 10. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3838: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000014019a9e 11. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3980: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000014018e31 12. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:4304: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000014042fa7 13. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5605: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000014013749 14. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000140127f9 15. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000014011fce 16. /build/src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000001406ce8a 17. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000014973b42 18. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000001497268d 19. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000014974d24 20. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001492924b 21. /build/src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88641 22. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 23. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 24. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 25. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 26. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 27. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 28. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 29. ? @ 0x00007fbc6213eac3 30. ? @ 0x00007fbc621d0850 2025.07.28 12:03:08.977893 [ 62056 ] {beb71c7e-7ef5-447c-bcbb-f2507f2400d8} executeQuery: Code: 43. DB::Exception: Datetime argument and origin argument for function toStartOfInterval must have the same type: In scope SELECT toStartOfInterval(toDateTime64('2023-01-02 14:45:50', 2), toIntervalMinute(1), toDate('2023-01-02 14:44:30')). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.6.10636.altinitytest (altinity build)) (from [::1]:51712) (comment: 02916_to_start_of_interval_with_origin.sql) (query 7, line 10) (in query: SELECT toStartOfInterval(toDateTime64('2023-01-02 14:45:50', 2), toIntervalMinute(1), toDate('2023-01-02 14:44:30'));), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x000000000a06b56b 4. /build/src/Functions/toStartOfInterval.cpp:134: DB::FunctionToStartOfInterval::getReturnTypeImpl(std::vector> const&) const::'lambda1'()::operator()() const @ 0x000000000e8bab81 5. /build/src/Functions/toStartOfInterval.cpp:169: DB::FunctionToStartOfInterval::getReturnTypeImpl(std::vector> const&) const @ 0x000000000e884ac4 6. /build/src/Functions/IFunction.cpp:645: DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x0000000012d96b0c 7. /build/src/Functions/IFunction.cpp:577: DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x0000000012d9669c 8. /build/src/Functions/IFunction.cpp:606: DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x0000000012d96edc 9. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3544: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000014033cc9 10. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3838: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000014019a9e 11. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3980: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000014018e31 12. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:4304: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000014042fa7 13. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5605: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000014013749 14. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000140127f9 15. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000014011fce 16. /build/src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000001406ce8a 17. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000014973b42 18. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000001497268d 19. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000014974d24 20. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001492924b 21. /build/src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88641 22. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 23. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 24. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 25. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 26. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 27. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 28. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 29. ? @ 0x00007fbc6213eac3 30. ? @ 0x00007fbc621d0850 2025.07.28 12:03:08.985978 [ 62056 ] {} TCPHandler: Code: 43. DB::Exception: Datetime argument and origin argument for function toStartOfInterval must have the same type: In scope SELECT toStartOfInterval(toDateTime64('2023-01-02 14:45:50', 2), toIntervalMinute(1), toDate('2023-01-02 14:44:30')). (ILLEGAL_TYPE_OF_ARGUMENT), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x000000000a06b56b 4. /build/src/Functions/toStartOfInterval.cpp:134: DB::FunctionToStartOfInterval::getReturnTypeImpl(std::vector> const&) const::'lambda1'()::operator()() const @ 0x000000000e8bab81 5. /build/src/Functions/toStartOfInterval.cpp:169: DB::FunctionToStartOfInterval::getReturnTypeImpl(std::vector> const&) const @ 0x000000000e884ac4 6. /build/src/Functions/IFunction.cpp:645: DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x0000000012d96b0c 7. /build/src/Functions/IFunction.cpp:577: DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x0000000012d9669c 8. /build/src/Functions/IFunction.cpp:606: DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x0000000012d96edc 9. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3544: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000014033cc9 10. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3838: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000014019a9e 11. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3980: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000014018e31 12. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:4304: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000014042fa7 13. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5605: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000014013749 14. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000140127f9 15. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000014011fce 16. /build/src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000001406ce8a 17. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000014973b42 18. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000001497268d 19. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000014974d24 20. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001492924b 21. /build/src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88641 22. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 23. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 24. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 25. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 26. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 27. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 28. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 29. ? @ 0x00007fbc6213eac3 30. ? @ 0x00007fbc621d0850 2025.07.28 12:03:09.140815 [ 62056 ] {2633e6ae-fe7a-4b7b-8ac1-f9a3ef6ac351} executeQuery: Code: 36. DB::Exception: The origin must be before the end date / date with time: In scope SELECT toStartOfInterval(toDateTime('2023-01-02 14:42:50'), toIntervalMinute(1), toDateTime('2023-01-02 14:44:30')). (BAD_ARGUMENTS) (version 25.3.6.10636.altinitytest (altinity build)) (from [::1]:51712) (comment: 02916_to_start_of_interval_with_origin.sql) (query 8, line 12) (in query: -- the origin must be before the time SELECT toStartOfInterval(toDateTime('2023-01-02 14:42:50'), toIntervalMinute(1), toDateTime('2023-01-02 14:44:30'));), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000000a074fcb 4. /build/src/Functions/toStartOfInterval.cpp:397: COW::immutable_ptr DB::FunctionToStartOfInterval::execute, (DB::IntervalKind::Kind)4>(DB::DataTypeDateTime const&, DB::ColumnVector const&, long, DB::ColumnWithTypeAndName const&, std::shared_ptr const&, DateLUTImpl const&, unsigned short) const @ 0x000000000e8a856b 5. /build/src/Functions/toStartOfInterval.cpp:337: COW::immutable_ptr DB::FunctionToStartOfInterval::dispatchForIntervalColumn>(DB::DataTypeDateTime const&, DB::ColumnVector const&, DB::ColumnWithTypeAndName const&, DB::ColumnWithTypeAndName const&, std::shared_ptr const&, DateLUTImpl const&, unsigned short) const @ 0x000000000e8a16f0 6. /build/src/Functions/toStartOfInterval.cpp:278: COW::immutable_ptr DB::FunctionToStartOfInterval::dispatchForTimeColumn(DB::ColumnWithTypeAndName const&, DB::ColumnWithTypeAndName const&, DB::ColumnWithTypeAndName const&, std::shared_ptr const&, DateLUTImpl const&) const @ 0x000000000e8856b9 7. /build/src/Functions/toStartOfInterval.cpp:247: DB::FunctionToStartOfInterval::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000e884627 8. /build/src/Functions/IFunction.h:437: DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000a069f2a 9. /build/src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000012d9965a 10. /build/src/Functions/IFunction.cpp:351: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d93b02 11. /build/src/Functions/IFunction.cpp:177: DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d93698 12. /build/src/Functions/IFunction.cpp:343: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d93aad 13. /build/src/Functions/IFunction.cpp:420: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d95059 14. /build/src/Functions/IFunction.cpp:498: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d95c72 15. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3567: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000014034494 16. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3838: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000014019a9e 17. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3980: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000014018e31 18. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:4304: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000014042fa7 19. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5605: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000014013749 20. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000140127f9 21. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000014011fce 22. /build/src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000001406ce8a 23. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000014973b42 24. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000001497268d 25. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000014974d24 26. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001492924b 27. /build/src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88641 28. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 29. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 30. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 31. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 2025.07.28 12:03:09.143778 [ 62056 ] {} TCPHandler: Code: 36. DB::Exception: The origin must be before the end date / date with time: In scope SELECT toStartOfInterval(toDateTime('2023-01-02 14:42:50'), toIntervalMinute(1), toDateTime('2023-01-02 14:44:30')). (BAD_ARGUMENTS), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000000a074fcb 4. /build/src/Functions/toStartOfInterval.cpp:397: COW::immutable_ptr DB::FunctionToStartOfInterval::execute, (DB::IntervalKind::Kind)4>(DB::DataTypeDateTime const&, DB::ColumnVector const&, long, DB::ColumnWithTypeAndName const&, std::shared_ptr const&, DateLUTImpl const&, unsigned short) const @ 0x000000000e8a856b 5. /build/src/Functions/toStartOfInterval.cpp:337: COW::immutable_ptr DB::FunctionToStartOfInterval::dispatchForIntervalColumn>(DB::DataTypeDateTime const&, DB::ColumnVector const&, DB::ColumnWithTypeAndName const&, DB::ColumnWithTypeAndName const&, std::shared_ptr const&, DateLUTImpl const&, unsigned short) const @ 0x000000000e8a16f0 6. /build/src/Functions/toStartOfInterval.cpp:278: COW::immutable_ptr DB::FunctionToStartOfInterval::dispatchForTimeColumn(DB::ColumnWithTypeAndName const&, DB::ColumnWithTypeAndName const&, DB::ColumnWithTypeAndName const&, std::shared_ptr const&, DateLUTImpl const&) const @ 0x000000000e8856b9 7. /build/src/Functions/toStartOfInterval.cpp:247: DB::FunctionToStartOfInterval::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000e884627 8. /build/src/Functions/IFunction.h:437: DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000a069f2a 9. /build/src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000012d9965a 10. /build/src/Functions/IFunction.cpp:351: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d93b02 11. /build/src/Functions/IFunction.cpp:177: DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d93698 12. /build/src/Functions/IFunction.cpp:343: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d93aad 13. /build/src/Functions/IFunction.cpp:420: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d95059 14. /build/src/Functions/IFunction.cpp:498: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d95c72 15. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3567: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000014034494 16. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3838: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000014019a9e 17. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3980: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000014018e31 18. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:4304: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000014042fa7 19. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5605: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000014013749 20. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000140127f9 21. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000014011fce 22. /build/src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000001406ce8a 23. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000014973b42 24. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000001497268d 25. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000014974d24 26. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001492924b 27. /build/src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88641 28. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 29. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 30. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 31. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 2025.07.28 12:03:09.205556 [ 62056 ] {7e03dc91-6471-4ec0-9bea-27bba9b24a16} executeQuery: Code: 44. DB::Exception: Argument at index 2 for function toStartOfInterval must be constant. (ILLEGAL_COLUMN) (version 25.3.6.10636.altinitytest (altinity build)) (from [::1]:51712) (comment: 02916_to_start_of_interval_with_origin.sql) (query 9, line 15) (in query: -- the origin must be constant SELECT toStartOfInterval(toDateTime('2023-01-02 14:45:50'), toIntervalMinute(1), number % 2 == 0 ? toDateTime('2023-02-01 15:55:00') : toDateTime('2023-01-01 15:55:00')) from numbers(1);), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, unsigned long&, String&&) @ 0x000000000ba5db6b 4. /build/src/Functions/IFunction.cpp:141: DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d93178 5. /build/src/Functions/IFunction.cpp:343: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d93aad 6. /build/src/Functions/IFunction.cpp:420: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d95059 7. /build/src/Functions/IFunction.cpp:498: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d95c72 8. /build/src/Interpreters/ActionsDAG.cpp:812: DB::ActionsDAG::evaluatePartialResult(std::unordered_map, std::equal_to, std::allocator>>&, std::vector> const&, unsigned long, bool) @ 0x0000000013fa38cc 9. /build/src/Interpreters/ActionsDAG.cpp:892: DB::ActionsDAG::updateHeader(DB::Block const&) const @ 0x0000000013fa29a8 10. /build/src/Processors/Transforms/ExpressionTransform.cpp:10: DB::ExpressionTransform::transformHeader(DB::Block const&, DB::ActionsDAG const&) @ 0x0000000016c0afd2 11. /build/src/Processors/QueryPlan/ExpressionStep.cpp:38: DB::ExpressionStep::ExpressionStep(DB::Block const&, DB::ActionsDAG) @ 0x0000000016db8ad1 12. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107](DB::Block const&, DB::ActionsDAG&&) @ 0x00000000131ee01a 13. /build/src/Planner/Planner.cpp:392: DB::(anonymous namespace)::addExpressionStep(DB::QueryPlan&, std::shared_ptr&, String const&, std::unordered_set, std::hash>, std::equal_to>, std::allocator>>&) @ 0x000000001498191d 14. /build/src/Planner/Planner.cpp:1648: DB::Planner::buildPlanForQueryNode() @ 0x000000001497b7aa 15. /build/src/Planner/Planner.cpp:1308: DB::Planner::buildQueryPlanIfNeeded() @ 0x000000001497685c 16. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:255: DB::InterpreterSelectQueryAnalyzer::getQueryPlan() @ 0x000000001497476d 17. /build/src/Interpreters/executeQuery.cpp:1405: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88806 18. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 19. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 20. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 21. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 22. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 23. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 24. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 25. ? @ 0x00007fbc6213eac3 26. ? @ 0x00007fbc621d0850 2025.07.28 12:03:09.210238 [ 62056 ] {} TCPHandler: Code: 44. DB::Exception: Argument at index 2 for function toStartOfInterval must be constant. (ILLEGAL_COLUMN), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, unsigned long&, String&&) @ 0x000000000ba5db6b 4. /build/src/Functions/IFunction.cpp:141: DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d93178 5. /build/src/Functions/IFunction.cpp:343: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d93aad 6. /build/src/Functions/IFunction.cpp:420: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d95059 7. /build/src/Functions/IFunction.cpp:498: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d95c72 8. /build/src/Interpreters/ActionsDAG.cpp:812: DB::ActionsDAG::evaluatePartialResult(std::unordered_map, std::equal_to, std::allocator>>&, std::vector> const&, unsigned long, bool) @ 0x0000000013fa38cc 9. /build/src/Interpreters/ActionsDAG.cpp:892: DB::ActionsDAG::updateHeader(DB::Block const&) const @ 0x0000000013fa29a8 10. /build/src/Processors/Transforms/ExpressionTransform.cpp:10: DB::ExpressionTransform::transformHeader(DB::Block const&, DB::ActionsDAG const&) @ 0x0000000016c0afd2 11. /build/src/Processors/QueryPlan/ExpressionStep.cpp:38: DB::ExpressionStep::ExpressionStep(DB::Block const&, DB::ActionsDAG) @ 0x0000000016db8ad1 12. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107](DB::Block const&, DB::ActionsDAG&&) @ 0x00000000131ee01a 13. /build/src/Planner/Planner.cpp:392: DB::(anonymous namespace)::addExpressionStep(DB::QueryPlan&, std::shared_ptr&, String const&, std::unordered_set, std::hash>, std::equal_to>, std::allocator>>&) @ 0x000000001498191d 14. /build/src/Planner/Planner.cpp:1648: DB::Planner::buildPlanForQueryNode() @ 0x000000001497b7aa 15. /build/src/Planner/Planner.cpp:1308: DB::Planner::buildQueryPlanIfNeeded() @ 0x000000001497685c 16. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:255: DB::InterpreterSelectQueryAnalyzer::getQueryPlan() @ 0x000000001497476d 17. /build/src/Interpreters/executeQuery.cpp:1405: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88806 18. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 19. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 20. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 21. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 22. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 23. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 24. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 25. ? @ 0x00007fbc6213eac3 26. ? @ 0x00007fbc621d0850 2025.07.28 12:03:09.257135 [ 62056 ] {97d9273e-65c3-4b13-9dde-5cbf2fb0ed1b} executeQuery: Code: 44. DB::Exception: Argument at index 2 for function toStartOfInterval must be constant. (ILLEGAL_COLUMN) (version 25.3.6.10636.altinitytest (altinity build)) (from [::1]:51712) (comment: 02916_to_start_of_interval_with_origin.sql) (query 10, line 17) (in query: SELECT toStartOfInterval(toDateTime('2023-01-02 14:45:50'), toIntervalHour(1), materialize(toDateTime('2023-01-02 14:44:30')), 'Europe/Amsterdam');), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, unsigned long&, String&&) @ 0x000000000ba5db6b 4. /build/src/Functions/IFunction.cpp:141: DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d93178 5. /build/src/Functions/IFunction.cpp:343: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d93aad 6. /build/src/Functions/IFunction.cpp:420: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d95059 7. /build/src/Functions/IFunction.cpp:498: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d95c72 8. /build/src/Interpreters/ActionsDAG.cpp:812: DB::ActionsDAG::evaluatePartialResult(std::unordered_map, std::equal_to, std::allocator>>&, std::vector> const&, unsigned long, bool) @ 0x0000000013fa38cc 9. /build/src/Interpreters/ActionsDAG.cpp:892: DB::ActionsDAG::updateHeader(DB::Block const&) const @ 0x0000000013fa29a8 10. /build/src/Processors/Transforms/ExpressionTransform.cpp:10: DB::ExpressionTransform::transformHeader(DB::Block const&, DB::ActionsDAG const&) @ 0x0000000016c0afd2 11. /build/src/Processors/QueryPlan/ExpressionStep.cpp:38: DB::ExpressionStep::ExpressionStep(DB::Block const&, DB::ActionsDAG) @ 0x0000000016db8ad1 12. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107](DB::Block const&, DB::ActionsDAG&&) @ 0x00000000131ee01a 13. /build/src/Planner/Planner.cpp:392: DB::(anonymous namespace)::addExpressionStep(DB::QueryPlan&, std::shared_ptr&, String const&, std::unordered_set, std::hash>, std::equal_to>, std::allocator>>&) @ 0x000000001498191d 14. /build/src/Planner/Planner.cpp:1648: DB::Planner::buildPlanForQueryNode() @ 0x000000001497b7aa 15. /build/src/Planner/Planner.cpp:1308: DB::Planner::buildQueryPlanIfNeeded() @ 0x000000001497685c 16. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:255: DB::InterpreterSelectQueryAnalyzer::getQueryPlan() @ 0x000000001497476d 17. /build/src/Interpreters/executeQuery.cpp:1405: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88806 18. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 19. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 20. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 21. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 22. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 23. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 24. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 25. ? @ 0x00007fbc6213eac3 26. ? @ 0x00007fbc621d0850 2025.07.28 12:03:09.261150 [ 62056 ] {} TCPHandler: Code: 44. DB::Exception: Argument at index 2 for function toStartOfInterval must be constant. (ILLEGAL_COLUMN), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, unsigned long&, String&&) @ 0x000000000ba5db6b 4. /build/src/Functions/IFunction.cpp:141: DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d93178 5. /build/src/Functions/IFunction.cpp:343: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d93aad 6. /build/src/Functions/IFunction.cpp:420: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d95059 7. /build/src/Functions/IFunction.cpp:498: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d95c72 8. /build/src/Interpreters/ActionsDAG.cpp:812: DB::ActionsDAG::evaluatePartialResult(std::unordered_map, std::equal_to, std::allocator>>&, std::vector> const&, unsigned long, bool) @ 0x0000000013fa38cc 9. /build/src/Interpreters/ActionsDAG.cpp:892: DB::ActionsDAG::updateHeader(DB::Block const&) const @ 0x0000000013fa29a8 10. /build/src/Processors/Transforms/ExpressionTransform.cpp:10: DB::ExpressionTransform::transformHeader(DB::Block const&, DB::ActionsDAG const&) @ 0x0000000016c0afd2 11. /build/src/Processors/QueryPlan/ExpressionStep.cpp:38: DB::ExpressionStep::ExpressionStep(DB::Block const&, DB::ActionsDAG) @ 0x0000000016db8ad1 12. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107](DB::Block const&, DB::ActionsDAG&&) @ 0x00000000131ee01a 13. /build/src/Planner/Planner.cpp:392: DB::(anonymous namespace)::addExpressionStep(DB::QueryPlan&, std::shared_ptr&, String const&, std::unordered_set, std::hash>, std::equal_to>, std::allocator>>&) @ 0x000000001498191d 14. /build/src/Planner/Planner.cpp:1648: DB::Planner::buildPlanForQueryNode() @ 0x000000001497b7aa 15. /build/src/Planner/Planner.cpp:1308: DB::Planner::buildQueryPlanIfNeeded() @ 0x000000001497685c 16. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:255: DB::InterpreterSelectQueryAnalyzer::getQueryPlan() @ 0x000000001497476d 17. /build/src/Interpreters/executeQuery.cpp:1405: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88806 18. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 19. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 20. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 21. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 22. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 23. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 24. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 25. ? @ 0x00007fbc6213eac3 26. ? @ 0x00007fbc621d0850 2025.07.28 12:03:09.426822 [ 3962 ] {} test_13.rmt2 (7f9b740d-015c-470e-8cc6-8ba33be0dc63): auto DB::StorageReplicatedMergeTree::processQueueEntry(ReplicatedMergeTreeQueue::SelectedEntryPtr)::(anonymous class)::operator()(LogEntryPtr &) const: Code: 86. DB::HTTPException: Received error from remote server http://146b4357c08d:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Ftest%2F01165%2Ftest_13%2Frmt%2Freplicas%2F1&part=20250728_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.6.10636.altinitytest (altinity build)) '. (RECEIVED_ERROR_FROM_REMOTE_IO_SERVER), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.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 const&, int&&, String const&, unsigned long&&, String const&) @ 0x000000000feda8d9 4. /build/src/IO/HTTPCommon.cpp:104: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x000000000feda6e2 5. /build/src/IO/HTTPCommon.cpp:93: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x000000000feda537 6. /build/src/IO/ReadWriteBufferFromHTTP.cpp:277: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x000000001184a4c4 7. /build/src/IO/ReadWriteBufferFromHTTP.cpp:285: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x000000001184a615 8. /build/src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x000000001184ae59 9. /build/src/IO/ReadWriteBufferFromHTTP.cpp:472: void std::__function::__policy_invoker::__call_impl[abi:se190107]>(std::__function::__policy_storage const*) @ 0x000000001184cedd 10. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001184858b 11. /build/src/IO/ReadWriteBufferFromHTTP.cpp:465: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x000000001184bf0b 12. /build/src/IO/ReadBuffer.h:60: DB::ReadBuffer::next() @ 0x000000000a148c7b 13. /build/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) @ 0x0000000011849fb2 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]>&)>&, 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&) @ 0x0000000011841980 15. /build/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) @ 0x000000001621208e 16. /build/src/Storages/StorageReplicatedMergeTree.cpp:5228: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl[abi:se190107] const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000015f9a5fe 17. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000015ed8bfd 18. /build/src/Storages/StorageReplicatedMergeTree.cpp:2514: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x0000000015ec9aab 19. /build/src/Storages/StorageReplicatedMergeTree.cpp:2349: DB::StorageReplicatedMergeTree::executeLogEntry(DB::ReplicatedMergeTreeLogEntry&) @ 0x0000000015eba91b 20. /build/src/Storages/StorageReplicatedMergeTree.cpp:3876: bool std::__function::__policy_invoker&)>::__call_impl[abi:se190107])::$_1, bool (std::shared_ptr&)>>(std::__function::__policy_storage const*, std::shared_ptr&) @ 0x0000000015f9837e 21. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000165d6fc3 22. /build/src/Storages/StorageReplicatedMergeTree.cpp:3872: DB::StorageReplicatedMergeTree::processQueueEntry(std::shared_ptr) @ 0x0000000015efc18a 23. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001624c1b2 24. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000162f9c70 25. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x00000000162fa55a 26. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc6653 27. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000000fccc4c3 28. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc3d92 29. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fcca080 30. ? @ 0x00007fbc6213eac3 31. ? @ 0x00007fbc621d0850 (version 25.3.6.10636.altinitytest (altinity build)) 2025.07.28 12:03:09.473448 [ 62056 ] {236af8a6-21ff-4dfa-9673-4db74444359d} executeQuery: Code: 43. DB::Exception: Illegal type String of 3rd argument of function toStartOfInterval. The third argument must a Date/Date32/DateTime/DateTime64 with a constant origin: In scope SELECT toStartOfInterval(toDateTime('2023-01-02 14:45:50'), toIntervalYear(1), 'Europe/Amsterdam', 'Europe/Amsterdam'). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.6.10636.altinitytest (altinity build)) (from [::1]:51712) (comment: 02916_to_start_of_interval_with_origin.sql) (query 11, line 19) (in query: -- with 4 arguments, the 3rd one must not be a string or an integer SELECT toStartOfInterval(toDateTime('2023-01-02 14:45:50'), toIntervalYear(1), 'Europe/Amsterdam', 'Europe/Amsterdam');), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000a06a8eb 4. /build/src/Functions/toStartOfInterval.cpp:145: DB::FunctionToStartOfInterval::getReturnTypeImpl(std::vector> const&) const::'lambda2'()::operator()() const @ 0x000000000e8bad75 5. /build/src/Functions/toStartOfInterval.cpp:176: DB::FunctionToStartOfInterval::getReturnTypeImpl(std::vector> const&) const @ 0x000000000e884b07 6. /build/src/Functions/IFunction.cpp:645: DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x0000000012d96b0c 7. /build/src/Functions/IFunction.cpp:577: DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x0000000012d9669c 8. /build/src/Functions/IFunction.cpp:606: DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x0000000012d96edc 9. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3544: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000014033cc9 10. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3838: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000014019a9e 11. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3980: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000014018e31 12. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:4304: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000014042fa7 13. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5605: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000014013749 14. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000140127f9 15. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000014011fce 16. /build/src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000001406ce8a 17. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000014973b42 18. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000001497268d 19. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000014974d24 20. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001492924b 21. /build/src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88641 22. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 23. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 24. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 25. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 26. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 27. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 28. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 29. ? @ 0x00007fbc6213eac3 30. ? @ 0x00007fbc621d0850 2025.07.28 12:03:09.477362 [ 62056 ] {} TCPHandler: Code: 43. DB::Exception: Illegal type String of 3rd argument of function toStartOfInterval. The third argument must a Date/Date32/DateTime/DateTime64 with a constant origin: In scope SELECT toStartOfInterval(toDateTime('2023-01-02 14:45:50'), toIntervalYear(1), 'Europe/Amsterdam', 'Europe/Amsterdam'). (ILLEGAL_TYPE_OF_ARGUMENT), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000a06a8eb 4. /build/src/Functions/toStartOfInterval.cpp:145: DB::FunctionToStartOfInterval::getReturnTypeImpl(std::vector> const&) const::'lambda2'()::operator()() const @ 0x000000000e8bad75 5. /build/src/Functions/toStartOfInterval.cpp:176: DB::FunctionToStartOfInterval::getReturnTypeImpl(std::vector> const&) const @ 0x000000000e884b07 6. /build/src/Functions/IFunction.cpp:645: DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x0000000012d96b0c 7. /build/src/Functions/IFunction.cpp:577: DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x0000000012d9669c 8. /build/src/Functions/IFunction.cpp:606: DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x0000000012d96edc 9. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3544: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000014033cc9 10. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3838: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000014019a9e 11. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3980: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000014018e31 12. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:4304: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000014042fa7 13. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5605: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000014013749 14. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000140127f9 15. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000014011fce 16. /build/src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000001406ce8a 17. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000014973b42 18. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000001497268d 19. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000014974d24 20. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001492924b 21. /build/src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88641 22. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 23. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 24. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 25. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 26. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 27. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 28. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 29. ? @ 0x00007fbc6213eac3 30. ? @ 0x00007fbc621d0850 2025.07.28 12:03:09.547136 [ 62056 ] {c4e5e443-ee89-4f79-a0c9-5a1f0bbf227d} executeQuery: Code: 43. DB::Exception: Illegal type UInt8 of 3rd argument of function toStartOfInterval. This argument is optional and must be a constant String with timezone name or a Date/Date32/DateTime/DateTime64 with a constant origin: In scope SELECT toStartOfInterval(toDateTime('2023-01-02 14:45:50'), toIntervalYear(1), 5, 'Europe/Amsterdam'). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.6.10636.altinitytest (altinity build)) (from [::1]:51712) (comment: 02916_to_start_of_interval_with_origin.sql) (query 12, line 21) (in query: SELECT toStartOfInterval(toDateTime('2023-01-02 14:45:50'), toIntervalYear(1), 5, 'Europe/Amsterdam');), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000a06a8eb 4. /build/src/Functions/toStartOfInterval.cpp:137: DB::FunctionToStartOfInterval::getReturnTypeImpl(std::vector> const&) const::'lambda1'()::operator()() const @ 0x000000000e8baae5 5. /build/src/Functions/toStartOfInterval.cpp:175: DB::FunctionToStartOfInterval::getReturnTypeImpl(std::vector> const&) const @ 0x000000000e884afa 6. /build/src/Functions/IFunction.cpp:645: DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x0000000012d96b0c 7. /build/src/Functions/IFunction.cpp:577: DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x0000000012d9669c 8. /build/src/Functions/IFunction.cpp:606: DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x0000000012d96edc 9. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3544: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000014033cc9 10. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3838: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000014019a9e 11. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3980: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000014018e31 12. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:4304: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000014042fa7 13. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5605: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000014013749 14. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000140127f9 15. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000014011fce 16. /build/src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000001406ce8a 17. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000014973b42 18. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000001497268d 19. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000014974d24 20. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001492924b 21. /build/src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88641 22. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 23. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 24. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 25. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 26. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 27. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 28. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 29. ? @ 0x00007fbc6213eac3 30. ? @ 0x00007fbc621d0850 2025.07.28 12:03:09.551261 [ 62056 ] {} TCPHandler: Code: 43. DB::Exception: Illegal type UInt8 of 3rd argument of function toStartOfInterval. This argument is optional and must be a constant String with timezone name or a Date/Date32/DateTime/DateTime64 with a constant origin: In scope SELECT toStartOfInterval(toDateTime('2023-01-02 14:45:50'), toIntervalYear(1), 5, 'Europe/Amsterdam'). (ILLEGAL_TYPE_OF_ARGUMENT), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000a06a8eb 4. /build/src/Functions/toStartOfInterval.cpp:137: DB::FunctionToStartOfInterval::getReturnTypeImpl(std::vector> const&) const::'lambda1'()::operator()() const @ 0x000000000e8baae5 5. /build/src/Functions/toStartOfInterval.cpp:175: DB::FunctionToStartOfInterval::getReturnTypeImpl(std::vector> const&) const @ 0x000000000e884afa 6. /build/src/Functions/IFunction.cpp:645: DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x0000000012d96b0c 7. /build/src/Functions/IFunction.cpp:577: DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x0000000012d9669c 8. /build/src/Functions/IFunction.cpp:606: DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x0000000012d96edc 9. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3544: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000014033cc9 10. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3838: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000014019a9e 11. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3980: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000014018e31 12. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:4304: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000014042fa7 13. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5605: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000014013749 14. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000140127f9 15. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000014011fce 16. /build/src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000001406ce8a 17. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000014973b42 18. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000001497268d 19. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000014974d24 20. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001492924b 21. /build/src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88641 22. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 23. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 24. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 25. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 26. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 27. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 28. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 29. ? @ 0x00007fbc6213eac3 30. ? @ 0x00007fbc621d0850 2025.07.28 12:03:09.669412 [ 62056 ] {01bba814-f1d0-4f4c-a6a7-98afcb11a33b} executeQuery: Code: 42. DB::Exception: Number of arguments for function toStartOfInterval doesn't match: passed 5, must be 2, 3 or 4: In scope SELECT toStartOfInterval(toDateTime('2023-01-02 14:45:50'), toIntervalYear(1), toDateTime('2020-01-02 14:44:30'), 'Europe/Amsterdam', 5). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.6.10636.altinitytest (altinity build)) (from [::1]:51712) (comment: 02916_to_start_of_interval_with_origin.sql) (query 13, line 23) (in query: -- too many arguments SELECT toStartOfInterval(toDateTime('2023-01-02 14:45:50'), toIntervalYear(1), toDateTime('2020-01-02 14:44:30'), 'Europe/Amsterdam', 5);), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, unsigned long&&) @ 0x000000000a06f86b 4. /build/src/Functions/toStartOfInterval.cpp:180: DB::FunctionToStartOfInterval::getReturnTypeImpl(std::vector> const&) const @ 0x000000000e884d71 5. /build/src/Functions/IFunction.cpp:645: DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x0000000012d96b0c 6. /build/src/Functions/IFunction.cpp:577: DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x0000000012d9669c 7. /build/src/Functions/IFunction.cpp:606: DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x0000000012d96edc 8. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3544: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000014033cc9 9. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3838: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000014019a9e 10. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3980: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000014018e31 11. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:4304: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000014042fa7 12. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5605: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000014013749 13. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000140127f9 14. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000014011fce 15. /build/src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000001406ce8a 16. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000014973b42 17. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000001497268d 18. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000014974d24 19. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001492924b 20. /build/src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88641 21. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 22. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 23. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 24. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 25. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 26. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 27. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 28. ? @ 0x00007fbc6213eac3 29. ? @ 0x00007fbc621d0850 2025.07.28 12:03:09.688073 [ 62056 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function toStartOfInterval doesn't match: passed 5, must be 2, 3 or 4: In scope SELECT toStartOfInterval(toDateTime('2023-01-02 14:45:50'), toIntervalYear(1), toDateTime('2020-01-02 14:44:30'), 'Europe/Amsterdam', 5). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, unsigned long&&) @ 0x000000000a06f86b 4. /build/src/Functions/toStartOfInterval.cpp:180: DB::FunctionToStartOfInterval::getReturnTypeImpl(std::vector> const&) const @ 0x000000000e884d71 5. /build/src/Functions/IFunction.cpp:645: DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x0000000012d96b0c 6. /build/src/Functions/IFunction.cpp:577: DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x0000000012d9669c 7. /build/src/Functions/IFunction.cpp:606: DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x0000000012d96edc 8. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3544: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000014033cc9 9. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3838: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000014019a9e 10. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3980: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000014018e31 11. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:4304: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000014042fa7 12. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5605: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000014013749 13. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000140127f9 14. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000014011fce 15. /build/src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000001406ce8a 16. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000014973b42 17. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000001497268d 18. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000014974d24 19. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001492924b 20. /build/src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88641 21. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 22. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 23. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 24. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 25. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 26. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 27. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 28. ? @ 0x00007fbc6213eac3 29. ? @ 0x00007fbc621d0850 2025.07.28 12:03:10.353842 [ 62056 ] {8ea4d1e9-37d6-4642-8ccc-a4bffd65ea0f} executeQuery: Code: 43. DB::Exception: Illegal interval kind for argument data type Date: In scope SELECT toStartOfInterval(toDate('2023-10-09'), toIntervalHour(1), toDate('2023-10-09')). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.6.10636.altinitytest (altinity build)) (from [::1]:51712) (comment: 02916_to_start_of_interval_with_origin.sql) (query 20, line 32) (in query: SELECT toStartOfInterval(toDate('2023-10-09'), toIntervalHour(1), toDate('2023-10-09'));), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000000a074fcb 4. /build/src/Functions/toStartOfInterval.cpp:312: COW::immutable_ptr DB::FunctionToStartOfInterval::dispatchForIntervalColumn>(DB::DataTypeDate const&, DB::ColumnVector const&, DB::ColumnWithTypeAndName const&, DB::ColumnWithTypeAndName const&, std::shared_ptr const&, DateLUTImpl const&, unsigned short) const @ 0x000000000e8861e7 5. /build/src/Functions/toStartOfInterval.cpp:266: COW::immutable_ptr DB::FunctionToStartOfInterval::dispatchForTimeColumn(DB::ColumnWithTypeAndName const&, DB::ColumnWithTypeAndName const&, DB::ColumnWithTypeAndName const&, std::shared_ptr const&, DateLUTImpl const&) const @ 0x000000000e884f79 6. /build/src/Functions/toStartOfInterval.cpp:243: DB::FunctionToStartOfInterval::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000e88450f 7. /build/src/Functions/IFunction.h:437: DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000a069f2a 8. /build/src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000012d9965a 9. /build/src/Functions/IFunction.cpp:351: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d93b02 10. /build/src/Functions/IFunction.cpp:177: DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d93698 11. /build/src/Functions/IFunction.cpp:343: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d93aad 12. /build/src/Functions/IFunction.cpp:420: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d95059 13. /build/src/Functions/IFunction.cpp:498: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d95c72 14. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3567: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000014034494 15. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3838: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000014019a9e 16. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3980: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000014018e31 17. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:4304: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000014042fa7 18. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5605: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000014013749 19. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000140127f9 20. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000014011fce 21. /build/src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000001406ce8a 22. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000014973b42 23. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000001497268d 24. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000014974d24 25. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001492924b 26. /build/src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88641 27. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 28. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 29. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 30. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 31. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 2025.07.28 12:03:10.356836 [ 62056 ] {} TCPHandler: Code: 43. DB::Exception: Illegal interval kind for argument data type Date: In scope SELECT toStartOfInterval(toDate('2023-10-09'), toIntervalHour(1), toDate('2023-10-09')). (ILLEGAL_TYPE_OF_ARGUMENT), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000000a074fcb 4. /build/src/Functions/toStartOfInterval.cpp:312: COW::immutable_ptr DB::FunctionToStartOfInterval::dispatchForIntervalColumn>(DB::DataTypeDate const&, DB::ColumnVector const&, DB::ColumnWithTypeAndName const&, DB::ColumnWithTypeAndName const&, std::shared_ptr const&, DateLUTImpl const&, unsigned short) const @ 0x000000000e8861e7 5. /build/src/Functions/toStartOfInterval.cpp:266: COW::immutable_ptr DB::FunctionToStartOfInterval::dispatchForTimeColumn(DB::ColumnWithTypeAndName const&, DB::ColumnWithTypeAndName const&, DB::ColumnWithTypeAndName const&, std::shared_ptr const&, DateLUTImpl const&) const @ 0x000000000e884f79 6. /build/src/Functions/toStartOfInterval.cpp:243: DB::FunctionToStartOfInterval::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000e88450f 7. /build/src/Functions/IFunction.h:437: DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000a069f2a 8. /build/src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000012d9965a 9. /build/src/Functions/IFunction.cpp:351: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d93b02 10. /build/src/Functions/IFunction.cpp:177: DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d93698 11. /build/src/Functions/IFunction.cpp:343: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d93aad 12. /build/src/Functions/IFunction.cpp:420: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d95059 13. /build/src/Functions/IFunction.cpp:498: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d95c72 14. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3567: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000014034494 15. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3838: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000014019a9e 16. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3980: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000014018e31 17. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:4304: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000014042fa7 18. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5605: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000014013749 19. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000140127f9 20. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000014011fce 21. /build/src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000001406ce8a 22. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000014973b42 23. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000001497268d 24. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000014974d24 25. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001492924b 26. /build/src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88641 27. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 28. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 29. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 30. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 31. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 2025.07.28 12:03:10.398883 [ 62056 ] {67b57b9a-23ff-4d42-9d25-67df84744a13} executeQuery: Code: 43. DB::Exception: Illegal interval kind for argument data type Date: In scope SELECT toStartOfInterval(toDate('2023-10-09'), toIntervalMinute(1), toDate('2023-10-09')). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.6.10636.altinitytest (altinity build)) (from [::1]:51712) (comment: 02916_to_start_of_interval_with_origin.sql) (query 21, line 33) (in query: SELECT toStartOfInterval(toDate('2023-10-09'), toIntervalMinute(1), toDate('2023-10-09'));), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000000a074fcb 4. /build/src/Functions/toStartOfInterval.cpp:312: COW::immutable_ptr DB::FunctionToStartOfInterval::dispatchForIntervalColumn>(DB::DataTypeDate const&, DB::ColumnVector const&, DB::ColumnWithTypeAndName const&, DB::ColumnWithTypeAndName const&, std::shared_ptr const&, DateLUTImpl const&, unsigned short) const @ 0x000000000e8861e7 5. /build/src/Functions/toStartOfInterval.cpp:266: COW::immutable_ptr DB::FunctionToStartOfInterval::dispatchForTimeColumn(DB::ColumnWithTypeAndName const&, DB::ColumnWithTypeAndName const&, DB::ColumnWithTypeAndName const&, std::shared_ptr const&, DateLUTImpl const&) const @ 0x000000000e884f79 6. /build/src/Functions/toStartOfInterval.cpp:243: DB::FunctionToStartOfInterval::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000e88450f 7. /build/src/Functions/IFunction.h:437: DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000a069f2a 8. /build/src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000012d9965a 9. /build/src/Functions/IFunction.cpp:351: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d93b02 10. /build/src/Functions/IFunction.cpp:177: DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d93698 11. /build/src/Functions/IFunction.cpp:343: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d93aad 12. /build/src/Functions/IFunction.cpp:420: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d95059 13. /build/src/Functions/IFunction.cpp:498: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d95c72 14. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3567: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000014034494 15. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3838: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000014019a9e 16. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3980: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000014018e31 17. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:4304: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000014042fa7 18. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5605: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000014013749 19. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000140127f9 20. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000014011fce 21. /build/src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000001406ce8a 22. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000014973b42 23. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000001497268d 24. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000014974d24 25. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001492924b 26. /build/src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88641 27. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 28. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 29. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 30. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 31. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 2025.07.28 12:03:10.403431 [ 62056 ] {} TCPHandler: Code: 43. DB::Exception: Illegal interval kind for argument data type Date: In scope SELECT toStartOfInterval(toDate('2023-10-09'), toIntervalMinute(1), toDate('2023-10-09')). (ILLEGAL_TYPE_OF_ARGUMENT), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000000a074fcb 4. /build/src/Functions/toStartOfInterval.cpp:312: COW::immutable_ptr DB::FunctionToStartOfInterval::dispatchForIntervalColumn>(DB::DataTypeDate const&, DB::ColumnVector const&, DB::ColumnWithTypeAndName const&, DB::ColumnWithTypeAndName const&, std::shared_ptr const&, DateLUTImpl const&, unsigned short) const @ 0x000000000e8861e7 5. /build/src/Functions/toStartOfInterval.cpp:266: COW::immutable_ptr DB::FunctionToStartOfInterval::dispatchForTimeColumn(DB::ColumnWithTypeAndName const&, DB::ColumnWithTypeAndName const&, DB::ColumnWithTypeAndName const&, std::shared_ptr const&, DateLUTImpl const&) const @ 0x000000000e884f79 6. /build/src/Functions/toStartOfInterval.cpp:243: DB::FunctionToStartOfInterval::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000e88450f 7. /build/src/Functions/IFunction.h:437: DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000a069f2a 8. /build/src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000012d9965a 9. /build/src/Functions/IFunction.cpp:351: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d93b02 10. /build/src/Functions/IFunction.cpp:177: DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d93698 11. /build/src/Functions/IFunction.cpp:343: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d93aad 12. /build/src/Functions/IFunction.cpp:420: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d95059 13. /build/src/Functions/IFunction.cpp:498: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d95c72 14. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3567: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000014034494 15. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3838: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000014019a9e 16. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3980: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000014018e31 17. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:4304: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000014042fa7 18. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5605: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000014013749 19. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000140127f9 20. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000014011fce 21. /build/src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000001406ce8a 22. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000014973b42 23. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000001497268d 24. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000014974d24 25. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001492924b 26. /build/src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88641 27. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 28. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 29. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 30. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 31. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 2025.07.28 12:03:10.585597 [ 62056 ] {512af2ba-7056-4c04-bc83-39ed2f6dfdd7} executeQuery: Code: 43. DB::Exception: Illegal interval kind for argument data type Date: In scope SELECT toStartOfInterval(toDate('2023-10-09'), toIntervalSecond(1), toDate('2023-10-09')). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.6.10636.altinitytest (altinity build)) (from [::1]:51712) (comment: 02916_to_start_of_interval_with_origin.sql) (query 22, line 34) (in query: SELECT toStartOfInterval(toDate('2023-10-09'), toIntervalSecond(1), toDate('2023-10-09'));), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000000a074fcb 4. /build/src/Functions/toStartOfInterval.cpp:312: COW::immutable_ptr DB::FunctionToStartOfInterval::dispatchForIntervalColumn>(DB::DataTypeDate const&, DB::ColumnVector const&, DB::ColumnWithTypeAndName const&, DB::ColumnWithTypeAndName const&, std::shared_ptr const&, DateLUTImpl const&, unsigned short) const @ 0x000000000e8861e7 5. /build/src/Functions/toStartOfInterval.cpp:266: COW::immutable_ptr DB::FunctionToStartOfInterval::dispatchForTimeColumn(DB::ColumnWithTypeAndName const&, DB::ColumnWithTypeAndName const&, DB::ColumnWithTypeAndName const&, std::shared_ptr const&, DateLUTImpl const&) const @ 0x000000000e884f79 6. /build/src/Functions/toStartOfInterval.cpp:243: DB::FunctionToStartOfInterval::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000e88450f 7. /build/src/Functions/IFunction.h:437: DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000a069f2a 8. /build/src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000012d9965a 9. /build/src/Functions/IFunction.cpp:351: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d93b02 10. /build/src/Functions/IFunction.cpp:177: DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d93698 11. /build/src/Functions/IFunction.cpp:343: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d93aad 12. /build/src/Functions/IFunction.cpp:420: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d95059 13. /build/src/Functions/IFunction.cpp:498: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d95c72 14. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3567: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000014034494 15. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3838: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000014019a9e 16. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3980: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000014018e31 17. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:4304: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000014042fa7 18. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5605: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000014013749 19. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000140127f9 20. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000014011fce 21. /build/src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000001406ce8a 22. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000014973b42 23. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000001497268d 24. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000014974d24 25. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001492924b 26. /build/src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88641 27. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 28. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 29. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 30. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 31. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 2025.07.28 12:03:10.586384 [ 3972 ] {} test_13.rmt2 (7f9b740d-015c-470e-8cc6-8ba33be0dc63): auto DB::StorageReplicatedMergeTree::processQueueEntry(ReplicatedMergeTreeQueue::SelectedEntryPtr)::(anonymous class)::operator()(LogEntryPtr &) const: Code: 86. DB::HTTPException: Received error from remote server http://146b4357c08d:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Ftest%2F01165%2Ftest_13%2Frmt%2Freplicas%2F1&part=20250728_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.6.10636.altinitytest (altinity build)) '. (RECEIVED_ERROR_FROM_REMOTE_IO_SERVER), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.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 const&, int&&, String const&, unsigned long&&, String const&) @ 0x000000000feda8d9 4. /build/src/IO/HTTPCommon.cpp:104: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x000000000feda6e2 5. /build/src/IO/HTTPCommon.cpp:93: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x000000000feda537 6. /build/src/IO/ReadWriteBufferFromHTTP.cpp:277: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x000000001184a4c4 7. /build/src/IO/ReadWriteBufferFromHTTP.cpp:285: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x000000001184a615 8. /build/src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x000000001184ae59 9. /build/src/IO/ReadWriteBufferFromHTTP.cpp:472: void std::__function::__policy_invoker::__call_impl[abi:se190107]>(std::__function::__policy_storage const*) @ 0x000000001184cedd 10. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001184858b 11. /build/src/IO/ReadWriteBufferFromHTTP.cpp:465: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x000000001184bf0b 12. /build/src/IO/ReadBuffer.h:60: DB::ReadBuffer::next() @ 0x000000000a148c7b 13. /build/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) @ 0x0000000011849fb2 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]>&)>&, 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&) @ 0x0000000011841980 15. /build/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) @ 0x000000001621208e 16. /build/src/Storages/StorageReplicatedMergeTree.cpp:5228: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl[abi:se190107] const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000015f9a5fe 17. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000015ed8bfd 18. /build/src/Storages/StorageReplicatedMergeTree.cpp:2514: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x0000000015ec9aab 19. /build/src/Storages/StorageReplicatedMergeTree.cpp:2349: DB::StorageReplicatedMergeTree::executeLogEntry(DB::ReplicatedMergeTreeLogEntry&) @ 0x0000000015eba91b 20. /build/src/Storages/StorageReplicatedMergeTree.cpp:3876: bool std::__function::__policy_invoker&)>::__call_impl[abi:se190107])::$_1, bool (std::shared_ptr&)>>(std::__function::__policy_storage const*, std::shared_ptr&) @ 0x0000000015f9837e 21. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000165d6fc3 22. /build/src/Storages/StorageReplicatedMergeTree.cpp:3872: DB::StorageReplicatedMergeTree::processQueueEntry(std::shared_ptr) @ 0x0000000015efc18a 23. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001624c1b2 24. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000162f9c70 25. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x00000000162fa55a 26. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc6653 27. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000000fccc4c3 28. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc3d92 29. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fcca080 30. ? @ 0x00007fbc6213eac3 31. ? @ 0x00007fbc621d0850 (version 25.3.6.10636.altinitytest (altinity build)) 2025.07.28 12:03:10.618898 [ 62056 ] {} TCPHandler: Code: 43. DB::Exception: Illegal interval kind for argument data type Date: In scope SELECT toStartOfInterval(toDate('2023-10-09'), toIntervalSecond(1), toDate('2023-10-09')). (ILLEGAL_TYPE_OF_ARGUMENT), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000000a074fcb 4. /build/src/Functions/toStartOfInterval.cpp:312: COW::immutable_ptr DB::FunctionToStartOfInterval::dispatchForIntervalColumn>(DB::DataTypeDate const&, DB::ColumnVector const&, DB::ColumnWithTypeAndName const&, DB::ColumnWithTypeAndName const&, std::shared_ptr const&, DateLUTImpl const&, unsigned short) const @ 0x000000000e8861e7 5. /build/src/Functions/toStartOfInterval.cpp:266: COW::immutable_ptr DB::FunctionToStartOfInterval::dispatchForTimeColumn(DB::ColumnWithTypeAndName const&, DB::ColumnWithTypeAndName const&, DB::ColumnWithTypeAndName const&, std::shared_ptr const&, DateLUTImpl const&) const @ 0x000000000e884f79 6. /build/src/Functions/toStartOfInterval.cpp:243: DB::FunctionToStartOfInterval::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000e88450f 7. /build/src/Functions/IFunction.h:437: DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000a069f2a 8. /build/src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000012d9965a 9. /build/src/Functions/IFunction.cpp:351: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d93b02 10. /build/src/Functions/IFunction.cpp:177: DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d93698 11. /build/src/Functions/IFunction.cpp:343: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d93aad 12. /build/src/Functions/IFunction.cpp:420: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d95059 13. /build/src/Functions/IFunction.cpp:498: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d95c72 14. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3567: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000014034494 15. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3838: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000014019a9e 16. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3980: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000014018e31 17. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:4304: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000014042fa7 18. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5605: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000014013749 19. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000140127f9 20. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000014011fce 21. /build/src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000001406ce8a 22. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000014973b42 23. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000001497268d 24. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000014974d24 25. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001492924b 26. /build/src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88641 27. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 28. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 29. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 30. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 31. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 2025.07.28 12:03:10.678918 [ 3964 ] {} test_13.rmt2 (7f9b740d-015c-470e-8cc6-8ba33be0dc63): auto DB::StorageReplicatedMergeTree::processQueueEntry(ReplicatedMergeTreeQueue::SelectedEntryPtr)::(anonymous class)::operator()(LogEntryPtr &) const: Code: 86. DB::HTTPException: Received error from remote server http://146b4357c08d:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Ftest%2F01165%2Ftest_13%2Frmt%2Freplicas%2F1&part=20250728_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.6.10636.altinitytest (altinity build)) '. (RECEIVED_ERROR_FROM_REMOTE_IO_SERVER), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.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 const&, int&&, String const&, unsigned long&&, String const&) @ 0x000000000feda8d9 4. /build/src/IO/HTTPCommon.cpp:104: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x000000000feda6e2 5. /build/src/IO/HTTPCommon.cpp:93: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x000000000feda537 6. /build/src/IO/ReadWriteBufferFromHTTP.cpp:277: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x000000001184a4c4 7. /build/src/IO/ReadWriteBufferFromHTTP.cpp:285: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x000000001184a615 8. /build/src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x000000001184ae59 9. /build/src/IO/ReadWriteBufferFromHTTP.cpp:472: void std::__function::__policy_invoker::__call_impl[abi:se190107]>(std::__function::__policy_storage const*) @ 0x000000001184cedd 10. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001184858b 11. /build/src/IO/ReadWriteBufferFromHTTP.cpp:465: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x000000001184bf0b 12. /build/src/IO/ReadBuffer.h:60: DB::ReadBuffer::next() @ 0x000000000a148c7b 13. /build/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) @ 0x0000000011849fb2 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]>&)>&, 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&) @ 0x0000000011841980 15. /build/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) @ 0x000000001621208e 16. /build/src/Storages/StorageReplicatedMergeTree.cpp:5228: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl[abi:se190107] const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000015f9a5fe 17. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000015ed8bfd 18. /build/src/Storages/StorageReplicatedMergeTree.cpp:2514: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x0000000015ec9aab 19. /build/src/Storages/StorageReplicatedMergeTree.cpp:2349: DB::StorageReplicatedMergeTree::executeLogEntry(DB::ReplicatedMergeTreeLogEntry&) @ 0x0000000015eba91b 20. /build/src/Storages/StorageReplicatedMergeTree.cpp:3876: bool std::__function::__policy_invoker&)>::__call_impl[abi:se190107])::$_1, bool (std::shared_ptr&)>>(std::__function::__policy_storage const*, std::shared_ptr&) @ 0x0000000015f9837e 21. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000165d6fc3 22. /build/src/Storages/StorageReplicatedMergeTree.cpp:3872: DB::StorageReplicatedMergeTree::processQueueEntry(std::shared_ptr) @ 0x0000000015efc18a 23. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001624c1b2 24. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000162f9c70 25. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x00000000162fa55a 26. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc6653 27. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000000fccc4c3 28. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc3d92 29. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fcca080 30. ? @ 0x00007fbc6213eac3 31. ? @ 0x00007fbc621d0850 (version 25.3.6.10636.altinitytest (altinity build)) 2025.07.28 12:03:10.771621 [ 62056 ] {80f3dc3c-dacb-4b36-a799-e67747b4e8d2} executeQuery: Code: 43. DB::Exception: Illegal interval kind for argument data type Date: In scope SELECT toStartOfInterval(toDate('2023-10-09'), toIntervalMillisecond(1), toDate('2023-10-09')). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.6.10636.altinitytest (altinity build)) (from [::1]:51712) (comment: 02916_to_start_of_interval_with_origin.sql) (query 23, line 35) (in query: SELECT toStartOfInterval(toDate('2023-10-09'), toIntervalMillisecond(1), toDate('2023-10-09'));), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type>, char const*&&) @ 0x000000000c7f5eab 4. /build/src/Functions/toStartOfInterval.cpp:306: COW::immutable_ptr DB::FunctionToStartOfInterval::dispatchForIntervalColumn>(DB::DataTypeDate const&, DB::ColumnVector const&, DB::ColumnWithTypeAndName const&, DB::ColumnWithTypeAndName const&, std::shared_ptr const&, DateLUTImpl const&, unsigned short) const @ 0x000000000e885c8a 5. /build/src/Functions/toStartOfInterval.cpp:266: COW::immutable_ptr DB::FunctionToStartOfInterval::dispatchForTimeColumn(DB::ColumnWithTypeAndName const&, DB::ColumnWithTypeAndName const&, DB::ColumnWithTypeAndName const&, std::shared_ptr const&, DateLUTImpl const&) const @ 0x000000000e884f79 6. /build/src/Functions/toStartOfInterval.cpp:243: DB::FunctionToStartOfInterval::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000e88450f 7. /build/src/Functions/IFunction.h:437: DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000a069f2a 8. /build/src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000012d9965a 9. /build/src/Functions/IFunction.cpp:351: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d93b02 10. /build/src/Functions/IFunction.cpp:177: DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d93698 11. /build/src/Functions/IFunction.cpp:343: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d93aad 12. /build/src/Functions/IFunction.cpp:420: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d95059 13. /build/src/Functions/IFunction.cpp:498: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d95c72 14. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3567: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000014034494 15. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3838: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000014019a9e 16. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3980: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000014018e31 17. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:4304: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000014042fa7 18. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5605: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000014013749 19. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000140127f9 20. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000014011fce 21. /build/src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000001406ce8a 22. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000014973b42 23. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000001497268d 24. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000014974d24 25. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001492924b 26. /build/src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88641 27. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 28. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 29. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 30. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 31. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 2025.07.28 12:03:10.847369 [ 62056 ] {} TCPHandler: Code: 43. DB::Exception: Illegal interval kind for argument data type Date: In scope SELECT toStartOfInterval(toDate('2023-10-09'), toIntervalMillisecond(1), toDate('2023-10-09')). (ILLEGAL_TYPE_OF_ARGUMENT), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type>, char const*&&) @ 0x000000000c7f5eab 4. /build/src/Functions/toStartOfInterval.cpp:306: COW::immutable_ptr DB::FunctionToStartOfInterval::dispatchForIntervalColumn>(DB::DataTypeDate const&, DB::ColumnVector const&, DB::ColumnWithTypeAndName const&, DB::ColumnWithTypeAndName const&, std::shared_ptr const&, DateLUTImpl const&, unsigned short) const @ 0x000000000e885c8a 5. /build/src/Functions/toStartOfInterval.cpp:266: COW::immutable_ptr DB::FunctionToStartOfInterval::dispatchForTimeColumn(DB::ColumnWithTypeAndName const&, DB::ColumnWithTypeAndName const&, DB::ColumnWithTypeAndName const&, std::shared_ptr const&, DateLUTImpl const&) const @ 0x000000000e884f79 6. /build/src/Functions/toStartOfInterval.cpp:243: DB::FunctionToStartOfInterval::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000e88450f 7. /build/src/Functions/IFunction.h:437: DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000a069f2a 8. /build/src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000012d9965a 9. /build/src/Functions/IFunction.cpp:351: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d93b02 10. /build/src/Functions/IFunction.cpp:177: DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d93698 11. /build/src/Functions/IFunction.cpp:343: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d93aad 12. /build/src/Functions/IFunction.cpp:420: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d95059 13. /build/src/Functions/IFunction.cpp:498: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d95c72 14. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3567: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000014034494 15. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3838: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000014019a9e 16. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3980: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000014018e31 17. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:4304: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000014042fa7 18. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5605: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000014013749 19. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000140127f9 20. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000014011fce 21. /build/src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000001406ce8a 22. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000014973b42 23. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000001497268d 24. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000014974d24 25. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001492924b 26. /build/src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88641 27. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 28. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 29. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 30. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 31. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 2025.07.28 12:03:10.921461 [ 62056 ] {d9ee627c-4348-49b0-8075-7f9e974167ff} executeQuery: Code: 43. DB::Exception: Illegal interval kind for argument data type Date: In scope SELECT toStartOfInterval(toDate('2023-10-09'), toIntervalMicrosecond(1), toDate('2023-10-09')). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.6.10636.altinitytest (altinity build)) (from [::1]:51712) (comment: 02916_to_start_of_interval_with_origin.sql) (query 24, line 36) (in query: SELECT toStartOfInterval(toDate('2023-10-09'), toIntervalMicrosecond(1), toDate('2023-10-09'));), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type>, char const*&&) @ 0x000000000c7f5eab 4. /build/src/Functions/toStartOfInterval.cpp:306: COW::immutable_ptr DB::FunctionToStartOfInterval::dispatchForIntervalColumn>(DB::DataTypeDate const&, DB::ColumnVector const&, DB::ColumnWithTypeAndName const&, DB::ColumnWithTypeAndName const&, std::shared_ptr const&, DateLUTImpl const&, unsigned short) const @ 0x000000000e885c8a 5. /build/src/Functions/toStartOfInterval.cpp:266: COW::immutable_ptr DB::FunctionToStartOfInterval::dispatchForTimeColumn(DB::ColumnWithTypeAndName const&, DB::ColumnWithTypeAndName const&, DB::ColumnWithTypeAndName const&, std::shared_ptr const&, DateLUTImpl const&) const @ 0x000000000e884f79 6. /build/src/Functions/toStartOfInterval.cpp:243: DB::FunctionToStartOfInterval::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000e88450f 7. /build/src/Functions/IFunction.h:437: DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000a069f2a 8. /build/src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000012d9965a 9. /build/src/Functions/IFunction.cpp:351: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d93b02 10. /build/src/Functions/IFunction.cpp:177: DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d93698 11. /build/src/Functions/IFunction.cpp:343: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d93aad 12. /build/src/Functions/IFunction.cpp:420: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d95059 13. /build/src/Functions/IFunction.cpp:498: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d95c72 14. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3567: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000014034494 15. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3838: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000014019a9e 16. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3980: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000014018e31 17. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:4304: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000014042fa7 18. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5605: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000014013749 19. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000140127f9 20. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000014011fce 21. /build/src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000001406ce8a 22. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000014973b42 23. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000001497268d 24. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000014974d24 25. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001492924b 26. /build/src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88641 27. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 28. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 29. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 30. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 31. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 2025.07.28 12:03:10.978687 [ 62056 ] {} TCPHandler: Code: 43. DB::Exception: Illegal interval kind for argument data type Date: In scope SELECT toStartOfInterval(toDate('2023-10-09'), toIntervalMicrosecond(1), toDate('2023-10-09')). (ILLEGAL_TYPE_OF_ARGUMENT), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type>, char const*&&) @ 0x000000000c7f5eab 4. /build/src/Functions/toStartOfInterval.cpp:306: COW::immutable_ptr DB::FunctionToStartOfInterval::dispatchForIntervalColumn>(DB::DataTypeDate const&, DB::ColumnVector const&, DB::ColumnWithTypeAndName const&, DB::ColumnWithTypeAndName const&, std::shared_ptr const&, DateLUTImpl const&, unsigned short) const @ 0x000000000e885c8a 5. /build/src/Functions/toStartOfInterval.cpp:266: COW::immutable_ptr DB::FunctionToStartOfInterval::dispatchForTimeColumn(DB::ColumnWithTypeAndName const&, DB::ColumnWithTypeAndName const&, DB::ColumnWithTypeAndName const&, std::shared_ptr const&, DateLUTImpl const&) const @ 0x000000000e884f79 6. /build/src/Functions/toStartOfInterval.cpp:243: DB::FunctionToStartOfInterval::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000e88450f 7. /build/src/Functions/IFunction.h:437: DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000a069f2a 8. /build/src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000012d9965a 9. /build/src/Functions/IFunction.cpp:351: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d93b02 10. /build/src/Functions/IFunction.cpp:177: DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d93698 11. /build/src/Functions/IFunction.cpp:343: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d93aad 12. /build/src/Functions/IFunction.cpp:420: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d95059 13. /build/src/Functions/IFunction.cpp:498: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d95c72 14. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3567: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000014034494 15. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3838: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000014019a9e 16. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3980: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000014018e31 17. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:4304: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000014042fa7 18. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5605: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000014013749 19. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000140127f9 20. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000014011fce 21. /build/src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000001406ce8a 22. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000014973b42 23. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000001497268d 24. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000014974d24 25. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001492924b 26. /build/src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88641 27. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 28. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 29. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 30. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 31. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 2025.07.28 12:03:11.024175 [ 62056 ] {2179a730-b938-4d69-afa8-e1c7cb3f7b58} executeQuery: Code: 43. DB::Exception: Illegal interval kind for argument data type Date: In scope SELECT toStartOfInterval(toDate('2023-10-09'), toIntervalNanosecond(1), toDate('2023-10-09')). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.6.10636.altinitytest (altinity build)) (from [::1]:51712) (comment: 02916_to_start_of_interval_with_origin.sql) (query 25, line 37) (in query: SELECT toStartOfInterval(toDate('2023-10-09'), toIntervalNanosecond(1), toDate('2023-10-09'));), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type>, char const*&&) @ 0x000000000c7f5eab 4. /build/src/Functions/toStartOfInterval.cpp:306: COW::immutable_ptr DB::FunctionToStartOfInterval::dispatchForIntervalColumn>(DB::DataTypeDate const&, DB::ColumnVector const&, DB::ColumnWithTypeAndName const&, DB::ColumnWithTypeAndName const&, std::shared_ptr const&, DateLUTImpl const&, unsigned short) const @ 0x000000000e885c8a 5. /build/src/Functions/toStartOfInterval.cpp:266: COW::immutable_ptr DB::FunctionToStartOfInterval::dispatchForTimeColumn(DB::ColumnWithTypeAndName const&, DB::ColumnWithTypeAndName const&, DB::ColumnWithTypeAndName const&, std::shared_ptr const&, DateLUTImpl const&) const @ 0x000000000e884f79 6. /build/src/Functions/toStartOfInterval.cpp:243: DB::FunctionToStartOfInterval::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000e88450f 7. /build/src/Functions/IFunction.h:437: DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000a069f2a 8. /build/src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000012d9965a 9. /build/src/Functions/IFunction.cpp:351: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d93b02 10. /build/src/Functions/IFunction.cpp:177: DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d93698 11. /build/src/Functions/IFunction.cpp:343: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d93aad 12. /build/src/Functions/IFunction.cpp:420: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d95059 13. /build/src/Functions/IFunction.cpp:498: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d95c72 14. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3567: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000014034494 15. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3838: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000014019a9e 16. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3980: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000014018e31 17. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:4304: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000014042fa7 18. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5605: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000014013749 19. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000140127f9 20. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000014011fce 21. /build/src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000001406ce8a 22. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000014973b42 23. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000001497268d 24. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000014974d24 25. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001492924b 26. /build/src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88641 27. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 28. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 29. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 30. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 31. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 2025.07.28 12:03:11.028386 [ 62056 ] {} TCPHandler: Code: 43. DB::Exception: Illegal interval kind for argument data type Date: In scope SELECT toStartOfInterval(toDate('2023-10-09'), toIntervalNanosecond(1), toDate('2023-10-09')). (ILLEGAL_TYPE_OF_ARGUMENT), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type>, char const*&&) @ 0x000000000c7f5eab 4. /build/src/Functions/toStartOfInterval.cpp:306: COW::immutable_ptr DB::FunctionToStartOfInterval::dispatchForIntervalColumn>(DB::DataTypeDate const&, DB::ColumnVector const&, DB::ColumnWithTypeAndName const&, DB::ColumnWithTypeAndName const&, std::shared_ptr const&, DateLUTImpl const&, unsigned short) const @ 0x000000000e885c8a 5. /build/src/Functions/toStartOfInterval.cpp:266: COW::immutable_ptr DB::FunctionToStartOfInterval::dispatchForTimeColumn(DB::ColumnWithTypeAndName const&, DB::ColumnWithTypeAndName const&, DB::ColumnWithTypeAndName const&, std::shared_ptr const&, DateLUTImpl const&) const @ 0x000000000e884f79 6. /build/src/Functions/toStartOfInterval.cpp:243: DB::FunctionToStartOfInterval::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000e88450f 7. /build/src/Functions/IFunction.h:437: DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000a069f2a 8. /build/src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000012d9965a 9. /build/src/Functions/IFunction.cpp:351: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d93b02 10. /build/src/Functions/IFunction.cpp:177: DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d93698 11. /build/src/Functions/IFunction.cpp:343: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d93aad 12. /build/src/Functions/IFunction.cpp:420: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d95059 13. /build/src/Functions/IFunction.cpp:498: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d95c72 14. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3567: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000014034494 15. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3838: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000014019a9e 16. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3980: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000014018e31 17. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:4304: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000014042fa7 18. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5605: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000014013749 19. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000140127f9 20. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000014011fce 21. /build/src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000001406ce8a 22. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000014973b42 23. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000001497268d 24. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000014974d24 25. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001492924b 26. /build/src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88641 27. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 28. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 29. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 30. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 31. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 2025.07.28 12:03:11.574697 [ 3971 ] {} test_13.rmt2 (7f9b740d-015c-470e-8cc6-8ba33be0dc63): auto DB::StorageReplicatedMergeTree::processQueueEntry(ReplicatedMergeTreeQueue::SelectedEntryPtr)::(anonymous class)::operator()(LogEntryPtr &) const: Code: 86. DB::HTTPException: Received error from remote server http://146b4357c08d:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Ftest%2F01165%2Ftest_13%2Frmt%2Freplicas%2F1&part=20250728_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.6.10636.altinitytest (altinity build)) '. (RECEIVED_ERROR_FROM_REMOTE_IO_SERVER), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.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 const&, int&&, String const&, unsigned long&&, String const&) @ 0x000000000feda8d9 4. /build/src/IO/HTTPCommon.cpp:104: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x000000000feda6e2 5. /build/src/IO/HTTPCommon.cpp:93: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x000000000feda537 6. /build/src/IO/ReadWriteBufferFromHTTP.cpp:277: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x000000001184a4c4 7. /build/src/IO/ReadWriteBufferFromHTTP.cpp:285: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x000000001184a615 8. /build/src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x000000001184ae59 9. /build/src/IO/ReadWriteBufferFromHTTP.cpp:472: void std::__function::__policy_invoker::__call_impl[abi:se190107]>(std::__function::__policy_storage const*) @ 0x000000001184cedd 10. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001184858b 11. /build/src/IO/ReadWriteBufferFromHTTP.cpp:465: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x000000001184bf0b 12. /build/src/IO/ReadBuffer.h:60: DB::ReadBuffer::next() @ 0x000000000a148c7b 13. /build/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) @ 0x0000000011849fb2 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]>&)>&, 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&) @ 0x0000000011841980 15. /build/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) @ 0x000000001621208e 16. /build/src/Storages/StorageReplicatedMergeTree.cpp:5228: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl[abi:se190107] const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000015f9a5fe 17. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000015ed8bfd 18. /build/src/Storages/StorageReplicatedMergeTree.cpp:2514: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x0000000015ec9aab 19. /build/src/Storages/StorageReplicatedMergeTree.cpp:2349: DB::StorageReplicatedMergeTree::executeLogEntry(DB::ReplicatedMergeTreeLogEntry&) @ 0x0000000015eba91b 20. /build/src/Storages/StorageReplicatedMergeTree.cpp:3876: bool std::__function::__policy_invoker&)>::__call_impl[abi:se190107])::$_1, bool (std::shared_ptr&)>>(std::__function::__policy_storage const*, std::shared_ptr&) @ 0x0000000015f9837e 21. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000165d6fc3 22. /build/src/Storages/StorageReplicatedMergeTree.cpp:3872: DB::StorageReplicatedMergeTree::processQueueEntry(std::shared_ptr) @ 0x0000000015efc18a 23. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001624c1b2 24. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000162f9c70 25. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x00000000162fa55a 26. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc6653 27. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000000fccc4c3 28. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc3d92 29. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fcca080 30. ? @ 0x00007fbc6213eac3 31. ? @ 0x00007fbc621d0850 (version 25.3.6.10636.altinitytest (altinity build)) 2025.07.28 12:03:11.948541 [ 62056 ] {cd04975a-29e5-4941-8fa4-78f8e903a6c8} executeQuery: Code: 43. DB::Exception: Illegal interval kind for argument data type Date: In scope SELECT toStartOfInterval(toDate32('2023-10-09'), toIntervalHour(1), toDate32('2023-10-09')). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.6.10636.altinitytest (altinity build)) (from [::1]:51712) (comment: 02916_to_start_of_interval_with_origin.sql) (query 32, line 45) (in query: SELECT toStartOfInterval(toDate32('2023-10-09'), toIntervalHour(1), toDate32('2023-10-09'));), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000000a074fcb 4. /build/src/Functions/toStartOfInterval.cpp:312: COW::immutable_ptr DB::FunctionToStartOfInterval::dispatchForIntervalColumn>(DB::DataTypeDate32 const&, DB::ColumnVector const&, DB::ColumnWithTypeAndName const&, DB::ColumnWithTypeAndName const&, std::shared_ptr const&, DateLUTImpl const&, unsigned short) const @ 0x000000000e8949e7 5. /build/src/Functions/toStartOfInterval.cpp:272: COW::immutable_ptr DB::FunctionToStartOfInterval::dispatchForTimeColumn(DB::ColumnWithTypeAndName const&, DB::ColumnWithTypeAndName const&, DB::ColumnWithTypeAndName const&, std::shared_ptr const&, DateLUTImpl const&) const @ 0x000000000e885319 6. /build/src/Functions/toStartOfInterval.cpp:245: DB::FunctionToStartOfInterval::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000e884574 7. /build/src/Functions/IFunction.h:437: DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000a069f2a 8. /build/src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000012d9965a 9. /build/src/Functions/IFunction.cpp:351: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d93b02 10. /build/src/Functions/IFunction.cpp:177: DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d93698 11. /build/src/Functions/IFunction.cpp:343: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d93aad 12. /build/src/Functions/IFunction.cpp:420: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d95059 13. /build/src/Functions/IFunction.cpp:498: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d95c72 14. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3567: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000014034494 15. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3838: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000014019a9e 16. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3980: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000014018e31 17. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:4304: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000014042fa7 18. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5605: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000014013749 19. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000140127f9 20. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000014011fce 21. /build/src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000001406ce8a 22. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000014973b42 23. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000001497268d 24. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000014974d24 25. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001492924b 26. /build/src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88641 27. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 28. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 29. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 30. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 31. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 2025.07.28 12:03:11.952294 [ 62056 ] {} TCPHandler: Code: 43. DB::Exception: Illegal interval kind for argument data type Date: In scope SELECT toStartOfInterval(toDate32('2023-10-09'), toIntervalHour(1), toDate32('2023-10-09')). (ILLEGAL_TYPE_OF_ARGUMENT), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000000a074fcb 4. /build/src/Functions/toStartOfInterval.cpp:312: COW::immutable_ptr DB::FunctionToStartOfInterval::dispatchForIntervalColumn>(DB::DataTypeDate32 const&, DB::ColumnVector const&, DB::ColumnWithTypeAndName const&, DB::ColumnWithTypeAndName const&, std::shared_ptr const&, DateLUTImpl const&, unsigned short) const @ 0x000000000e8949e7 5. /build/src/Functions/toStartOfInterval.cpp:272: COW::immutable_ptr DB::FunctionToStartOfInterval::dispatchForTimeColumn(DB::ColumnWithTypeAndName const&, DB::ColumnWithTypeAndName const&, DB::ColumnWithTypeAndName const&, std::shared_ptr const&, DateLUTImpl const&) const @ 0x000000000e885319 6. /build/src/Functions/toStartOfInterval.cpp:245: DB::FunctionToStartOfInterval::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000e884574 7. /build/src/Functions/IFunction.h:437: DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000a069f2a 8. /build/src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000012d9965a 9. /build/src/Functions/IFunction.cpp:351: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d93b02 10. /build/src/Functions/IFunction.cpp:177: DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d93698 11. /build/src/Functions/IFunction.cpp:343: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d93aad 12. /build/src/Functions/IFunction.cpp:420: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d95059 13. /build/src/Functions/IFunction.cpp:498: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d95c72 14. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3567: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000014034494 15. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3838: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000014019a9e 16. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3980: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000014018e31 17. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:4304: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000014042fa7 18. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5605: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000014013749 19. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000140127f9 20. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000014011fce 21. /build/src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000001406ce8a 22. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000014973b42 23. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000001497268d 24. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000014974d24 25. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001492924b 26. /build/src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88641 27. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 28. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 29. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 30. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 31. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 2025.07.28 12:03:11.984783 [ 62056 ] {2d5fba14-b1da-4b25-8907-ece000e048ff} executeQuery: Code: 43. DB::Exception: Illegal interval kind for argument data type Date: In scope SELECT toStartOfInterval(toDate32('2023-10-09'), toIntervalMinute(1), toDate32('2023-10-09')). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.6.10636.altinitytest (altinity build)) (from [::1]:51712) (comment: 02916_to_start_of_interval_with_origin.sql) (query 33, line 46) (in query: SELECT toStartOfInterval(toDate32('2023-10-09'), toIntervalMinute(1), toDate32('2023-10-09'));), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000000a074fcb 4. /build/src/Functions/toStartOfInterval.cpp:312: COW::immutable_ptr DB::FunctionToStartOfInterval::dispatchForIntervalColumn>(DB::DataTypeDate32 const&, DB::ColumnVector const&, DB::ColumnWithTypeAndName const&, DB::ColumnWithTypeAndName const&, std::shared_ptr const&, DateLUTImpl const&, unsigned short) const @ 0x000000000e8949e7 5. /build/src/Functions/toStartOfInterval.cpp:272: COW::immutable_ptr DB::FunctionToStartOfInterval::dispatchForTimeColumn(DB::ColumnWithTypeAndName const&, DB::ColumnWithTypeAndName const&, DB::ColumnWithTypeAndName const&, std::shared_ptr const&, DateLUTImpl const&) const @ 0x000000000e885319 6. /build/src/Functions/toStartOfInterval.cpp:245: DB::FunctionToStartOfInterval::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000e884574 7. /build/src/Functions/IFunction.h:437: DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000a069f2a 8. /build/src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000012d9965a 9. /build/src/Functions/IFunction.cpp:351: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d93b02 10. /build/src/Functions/IFunction.cpp:177: DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d93698 11. /build/src/Functions/IFunction.cpp:343: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d93aad 12. /build/src/Functions/IFunction.cpp:420: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d95059 13. /build/src/Functions/IFunction.cpp:498: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d95c72 14. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3567: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000014034494 15. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3838: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000014019a9e 16. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3980: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000014018e31 17. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:4304: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000014042fa7 18. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5605: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000014013749 19. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000140127f9 20. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000014011fce 21. /build/src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000001406ce8a 22. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000014973b42 23. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000001497268d 24. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000014974d24 25. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001492924b 26. /build/src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88641 27. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 28. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 29. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 30. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 31. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 2025.07.28 12:03:11.988855 [ 62056 ] {} TCPHandler: Code: 43. DB::Exception: Illegal interval kind for argument data type Date: In scope SELECT toStartOfInterval(toDate32('2023-10-09'), toIntervalMinute(1), toDate32('2023-10-09')). (ILLEGAL_TYPE_OF_ARGUMENT), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000000a074fcb 4. /build/src/Functions/toStartOfInterval.cpp:312: COW::immutable_ptr DB::FunctionToStartOfInterval::dispatchForIntervalColumn>(DB::DataTypeDate32 const&, DB::ColumnVector const&, DB::ColumnWithTypeAndName const&, DB::ColumnWithTypeAndName const&, std::shared_ptr const&, DateLUTImpl const&, unsigned short) const @ 0x000000000e8949e7 5. /build/src/Functions/toStartOfInterval.cpp:272: COW::immutable_ptr DB::FunctionToStartOfInterval::dispatchForTimeColumn(DB::ColumnWithTypeAndName const&, DB::ColumnWithTypeAndName const&, DB::ColumnWithTypeAndName const&, std::shared_ptr const&, DateLUTImpl const&) const @ 0x000000000e885319 6. /build/src/Functions/toStartOfInterval.cpp:245: DB::FunctionToStartOfInterval::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000e884574 7. /build/src/Functions/IFunction.h:437: DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000a069f2a 8. /build/src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000012d9965a 9. /build/src/Functions/IFunction.cpp:351: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d93b02 10. /build/src/Functions/IFunction.cpp:177: DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d93698 11. /build/src/Functions/IFunction.cpp:343: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d93aad 12. /build/src/Functions/IFunction.cpp:420: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d95059 13. /build/src/Functions/IFunction.cpp:498: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d95c72 14. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3567: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000014034494 15. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3838: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000014019a9e 16. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3980: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000014018e31 17. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:4304: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000014042fa7 18. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5605: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000014013749 19. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000140127f9 20. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000014011fce 21. /build/src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000001406ce8a 22. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000014973b42 23. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000001497268d 24. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000014974d24 25. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001492924b 26. /build/src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88641 27. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 28. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 29. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 30. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 31. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 2025.07.28 12:03:12.020350 [ 62056 ] {47698243-477b-4d2f-853e-cbc2c49bea31} executeQuery: Code: 43. DB::Exception: Illegal interval kind for argument data type Date: In scope SELECT toStartOfInterval(toDate32('2023-10-09'), toIntervalSecond(1), toDate32('2023-10-09')). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.6.10636.altinitytest (altinity build)) (from [::1]:51712) (comment: 02916_to_start_of_interval_with_origin.sql) (query 34, line 47) (in query: SELECT toStartOfInterval(toDate32('2023-10-09'), toIntervalSecond(1), toDate32('2023-10-09'));), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000000a074fcb 4. /build/src/Functions/toStartOfInterval.cpp:312: COW::immutable_ptr DB::FunctionToStartOfInterval::dispatchForIntervalColumn>(DB::DataTypeDate32 const&, DB::ColumnVector const&, DB::ColumnWithTypeAndName const&, DB::ColumnWithTypeAndName const&, std::shared_ptr const&, DateLUTImpl const&, unsigned short) const @ 0x000000000e8949e7 5. /build/src/Functions/toStartOfInterval.cpp:272: COW::immutable_ptr DB::FunctionToStartOfInterval::dispatchForTimeColumn(DB::ColumnWithTypeAndName const&, DB::ColumnWithTypeAndName const&, DB::ColumnWithTypeAndName const&, std::shared_ptr const&, DateLUTImpl const&) const @ 0x000000000e885319 6. /build/src/Functions/toStartOfInterval.cpp:245: DB::FunctionToStartOfInterval::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000e884574 7. /build/src/Functions/IFunction.h:437: DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000a069f2a 8. /build/src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000012d9965a 9. /build/src/Functions/IFunction.cpp:351: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d93b02 10. /build/src/Functions/IFunction.cpp:177: DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d93698 11. /build/src/Functions/IFunction.cpp:343: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d93aad 12. /build/src/Functions/IFunction.cpp:420: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d95059 13. /build/src/Functions/IFunction.cpp:498: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d95c72 14. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3567: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000014034494 15. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3838: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000014019a9e 16. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3980: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000014018e31 17. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:4304: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000014042fa7 18. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5605: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000014013749 19. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000140127f9 20. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000014011fce 21. /build/src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000001406ce8a 22. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000014973b42 23. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000001497268d 24. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000014974d24 25. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001492924b 26. /build/src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88641 27. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 28. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 29. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 30. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 31. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 2025.07.28 12:03:12.024453 [ 62056 ] {} TCPHandler: Code: 43. DB::Exception: Illegal interval kind for argument data type Date: In scope SELECT toStartOfInterval(toDate32('2023-10-09'), toIntervalSecond(1), toDate32('2023-10-09')). (ILLEGAL_TYPE_OF_ARGUMENT), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000000a074fcb 4. /build/src/Functions/toStartOfInterval.cpp:312: COW::immutable_ptr DB::FunctionToStartOfInterval::dispatchForIntervalColumn>(DB::DataTypeDate32 const&, DB::ColumnVector const&, DB::ColumnWithTypeAndName const&, DB::ColumnWithTypeAndName const&, std::shared_ptr const&, DateLUTImpl const&, unsigned short) const @ 0x000000000e8949e7 5. /build/src/Functions/toStartOfInterval.cpp:272: COW::immutable_ptr DB::FunctionToStartOfInterval::dispatchForTimeColumn(DB::ColumnWithTypeAndName const&, DB::ColumnWithTypeAndName const&, DB::ColumnWithTypeAndName const&, std::shared_ptr const&, DateLUTImpl const&) const @ 0x000000000e885319 6. /build/src/Functions/toStartOfInterval.cpp:245: DB::FunctionToStartOfInterval::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000e884574 7. /build/src/Functions/IFunction.h:437: DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000a069f2a 8. /build/src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000012d9965a 9. /build/src/Functions/IFunction.cpp:351: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d93b02 10. /build/src/Functions/IFunction.cpp:177: DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d93698 11. /build/src/Functions/IFunction.cpp:343: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d93aad 12. /build/src/Functions/IFunction.cpp:420: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d95059 13. /build/src/Functions/IFunction.cpp:498: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d95c72 14. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3567: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000014034494 15. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3838: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000014019a9e 16. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3980: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000014018e31 17. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:4304: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000014042fa7 18. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5605: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000014013749 19. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000140127f9 20. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000014011fce 21. /build/src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000001406ce8a 22. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000014973b42 23. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000001497268d 24. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000014974d24 25. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001492924b 26. /build/src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88641 27. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 28. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 29. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 30. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 31. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 2025.07.28 12:03:12.074564 [ 62056 ] {74871ea6-a620-4f16-9eb7-92b132a8cee0} executeQuery: Code: 43. DB::Exception: Illegal interval kind for argument data type DateTime: In scope SELECT toStartOfInterval(toDate32('2023-10-09'), toIntervalMillisecond(1), toDate32('2023-10-09')). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.6.10636.altinitytest (altinity build)) (from [::1]:51712) (comment: 02916_to_start_of_interval_with_origin.sql) (query 35, line 48) (in query: SELECT toStartOfInterval(toDate32('2023-10-09'), toIntervalMillisecond(1), toDate32('2023-10-09'));), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type>, char const*&&) @ 0x000000000c7f5eab 4. /build/src/Functions/toStartOfInterval.cpp:306: COW::immutable_ptr DB::FunctionToStartOfInterval::dispatchForIntervalColumn>(DB::DataTypeDate32 const&, DB::ColumnVector const&, DB::ColumnWithTypeAndName const&, DB::ColumnWithTypeAndName const&, std::shared_ptr const&, DateLUTImpl const&, unsigned short) const @ 0x000000000e89448a 5. /build/src/Functions/toStartOfInterval.cpp:272: COW::immutable_ptr DB::FunctionToStartOfInterval::dispatchForTimeColumn(DB::ColumnWithTypeAndName const&, DB::ColumnWithTypeAndName const&, DB::ColumnWithTypeAndName const&, std::shared_ptr const&, DateLUTImpl const&) const @ 0x000000000e885319 6. /build/src/Functions/toStartOfInterval.cpp:245: DB::FunctionToStartOfInterval::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000e884574 7. /build/src/Functions/IFunction.h:437: DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000a069f2a 8. /build/src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000012d9965a 9. /build/src/Functions/IFunction.cpp:351: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d93b02 10. /build/src/Functions/IFunction.cpp:177: DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d93698 11. /build/src/Functions/IFunction.cpp:343: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d93aad 12. /build/src/Functions/IFunction.cpp:420: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d95059 13. /build/src/Functions/IFunction.cpp:498: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d95c72 14. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3567: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000014034494 15. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3838: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000014019a9e 16. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3980: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000014018e31 17. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:4304: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000014042fa7 18. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5605: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000014013749 19. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000140127f9 20. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000014011fce 21. /build/src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000001406ce8a 22. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000014973b42 23. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000001497268d 24. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000014974d24 25. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001492924b 26. /build/src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88641 27. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 28. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 29. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 30. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 31. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 2025.07.28 12:03:12.078305 [ 62056 ] {} TCPHandler: Code: 43. DB::Exception: Illegal interval kind for argument data type DateTime: In scope SELECT toStartOfInterval(toDate32('2023-10-09'), toIntervalMillisecond(1), toDate32('2023-10-09')). (ILLEGAL_TYPE_OF_ARGUMENT), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type>, char const*&&) @ 0x000000000c7f5eab 4. /build/src/Functions/toStartOfInterval.cpp:306: COW::immutable_ptr DB::FunctionToStartOfInterval::dispatchForIntervalColumn>(DB::DataTypeDate32 const&, DB::ColumnVector const&, DB::ColumnWithTypeAndName const&, DB::ColumnWithTypeAndName const&, std::shared_ptr const&, DateLUTImpl const&, unsigned short) const @ 0x000000000e89448a 5. /build/src/Functions/toStartOfInterval.cpp:272: COW::immutable_ptr DB::FunctionToStartOfInterval::dispatchForTimeColumn(DB::ColumnWithTypeAndName const&, DB::ColumnWithTypeAndName const&, DB::ColumnWithTypeAndName const&, std::shared_ptr const&, DateLUTImpl const&) const @ 0x000000000e885319 6. /build/src/Functions/toStartOfInterval.cpp:245: DB::FunctionToStartOfInterval::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000e884574 7. /build/src/Functions/IFunction.h:437: DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000a069f2a 8. /build/src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000012d9965a 9. /build/src/Functions/IFunction.cpp:351: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d93b02 10. /build/src/Functions/IFunction.cpp:177: DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d93698 11. /build/src/Functions/IFunction.cpp:343: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d93aad 12. /build/src/Functions/IFunction.cpp:420: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d95059 13. /build/src/Functions/IFunction.cpp:498: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d95c72 14. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3567: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000014034494 15. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3838: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000014019a9e 16. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3980: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000014018e31 17. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:4304: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000014042fa7 18. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5605: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000014013749 19. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000140127f9 20. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000014011fce 21. /build/src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000001406ce8a 22. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000014973b42 23. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000001497268d 24. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000014974d24 25. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001492924b 26. /build/src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88641 27. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 28. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 29. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 30. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 31. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 2025.07.28 12:03:12.116944 [ 62056 ] {331cb987-56e5-4fd9-b48c-3a1cfd21bfeb} executeQuery: Code: 43. DB::Exception: Illegal interval kind for argument data type DateTime: In scope SELECT toStartOfInterval(toDate32('2023-10-09'), toIntervalMicrosecond(1), toDate32('2023-10-09')). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.6.10636.altinitytest (altinity build)) (from [::1]:51712) (comment: 02916_to_start_of_interval_with_origin.sql) (query 36, line 49) (in query: SELECT toStartOfInterval(toDate32('2023-10-09'), toIntervalMicrosecond(1), toDate32('2023-10-09'));), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type>, char const*&&) @ 0x000000000c7f5eab 4. /build/src/Functions/toStartOfInterval.cpp:306: COW::immutable_ptr DB::FunctionToStartOfInterval::dispatchForIntervalColumn>(DB::DataTypeDate32 const&, DB::ColumnVector const&, DB::ColumnWithTypeAndName const&, DB::ColumnWithTypeAndName const&, std::shared_ptr const&, DateLUTImpl const&, unsigned short) const @ 0x000000000e89448a 5. /build/src/Functions/toStartOfInterval.cpp:272: COW::immutable_ptr DB::FunctionToStartOfInterval::dispatchForTimeColumn(DB::ColumnWithTypeAndName const&, DB::ColumnWithTypeAndName const&, DB::ColumnWithTypeAndName const&, std::shared_ptr const&, DateLUTImpl const&) const @ 0x000000000e885319 6. /build/src/Functions/toStartOfInterval.cpp:245: DB::FunctionToStartOfInterval::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000e884574 7. /build/src/Functions/IFunction.h:437: DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000a069f2a 8. /build/src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000012d9965a 9. /build/src/Functions/IFunction.cpp:351: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d93b02 10. /build/src/Functions/IFunction.cpp:177: DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d93698 11. /build/src/Functions/IFunction.cpp:343: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d93aad 12. /build/src/Functions/IFunction.cpp:420: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d95059 13. /build/src/Functions/IFunction.cpp:498: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d95c72 14. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3567: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000014034494 15. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3838: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000014019a9e 16. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3980: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000014018e31 17. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:4304: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000014042fa7 18. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5605: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000014013749 19. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000140127f9 20. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000014011fce 21. /build/src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000001406ce8a 22. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000014973b42 23. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000001497268d 24. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000014974d24 25. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001492924b 26. /build/src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88641 27. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 28. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 29. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 30. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 31. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 2025.07.28 12:03:12.129565 [ 62056 ] {} TCPHandler: Code: 43. DB::Exception: Illegal interval kind for argument data type DateTime: In scope SELECT toStartOfInterval(toDate32('2023-10-09'), toIntervalMicrosecond(1), toDate32('2023-10-09')). (ILLEGAL_TYPE_OF_ARGUMENT), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type>, char const*&&) @ 0x000000000c7f5eab 4. /build/src/Functions/toStartOfInterval.cpp:306: COW::immutable_ptr DB::FunctionToStartOfInterval::dispatchForIntervalColumn>(DB::DataTypeDate32 const&, DB::ColumnVector const&, DB::ColumnWithTypeAndName const&, DB::ColumnWithTypeAndName const&, std::shared_ptr const&, DateLUTImpl const&, unsigned short) const @ 0x000000000e89448a 5. /build/src/Functions/toStartOfInterval.cpp:272: COW::immutable_ptr DB::FunctionToStartOfInterval::dispatchForTimeColumn(DB::ColumnWithTypeAndName const&, DB::ColumnWithTypeAndName const&, DB::ColumnWithTypeAndName const&, std::shared_ptr const&, DateLUTImpl const&) const @ 0x000000000e885319 6. /build/src/Functions/toStartOfInterval.cpp:245: DB::FunctionToStartOfInterval::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000e884574 7. /build/src/Functions/IFunction.h:437: DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000a069f2a 8. /build/src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000012d9965a 9. /build/src/Functions/IFunction.cpp:351: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d93b02 10. /build/src/Functions/IFunction.cpp:177: DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d93698 11. /build/src/Functions/IFunction.cpp:343: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d93aad 12. /build/src/Functions/IFunction.cpp:420: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d95059 13. /build/src/Functions/IFunction.cpp:498: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d95c72 14. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3567: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000014034494 15. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3838: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000014019a9e 16. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3980: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000014018e31 17. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:4304: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000014042fa7 18. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5605: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000014013749 19. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000140127f9 20. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000014011fce 21. /build/src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000001406ce8a 22. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000014973b42 23. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000001497268d 24. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000014974d24 25. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001492924b 26. /build/src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88641 27. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 28. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 29. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 30. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 31. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 2025.07.28 12:03:12.229343 [ 62056 ] {0ff810c3-46cb-4be7-8770-6526b19fadfc} executeQuery: Code: 43. DB::Exception: Illegal interval kind for argument data type DateTime: In scope SELECT toStartOfInterval(toDate32('2023-10-09'), toIntervalNanosecond(1), toDate32('2023-10-09')). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.6.10636.altinitytest (altinity build)) (from [::1]:51712) (comment: 02916_to_start_of_interval_with_origin.sql) (query 37, line 50) (in query: SELECT toStartOfInterval(toDate32('2023-10-09'), toIntervalNanosecond(1), toDate32('2023-10-09'));), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type>, char const*&&) @ 0x000000000c7f5eab 4. /build/src/Functions/toStartOfInterval.cpp:306: COW::immutable_ptr DB::FunctionToStartOfInterval::dispatchForIntervalColumn>(DB::DataTypeDate32 const&, DB::ColumnVector const&, DB::ColumnWithTypeAndName const&, DB::ColumnWithTypeAndName const&, std::shared_ptr const&, DateLUTImpl const&, unsigned short) const @ 0x000000000e89448a 5. /build/src/Functions/toStartOfInterval.cpp:272: COW::immutable_ptr DB::FunctionToStartOfInterval::dispatchForTimeColumn(DB::ColumnWithTypeAndName const&, DB::ColumnWithTypeAndName const&, DB::ColumnWithTypeAndName const&, std::shared_ptr const&, DateLUTImpl const&) const @ 0x000000000e885319 6. /build/src/Functions/toStartOfInterval.cpp:245: DB::FunctionToStartOfInterval::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000e884574 7. /build/src/Functions/IFunction.h:437: DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000a069f2a 8. /build/src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000012d9965a 9. /build/src/Functions/IFunction.cpp:351: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d93b02 10. /build/src/Functions/IFunction.cpp:177: DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d93698 11. /build/src/Functions/IFunction.cpp:343: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d93aad 12. /build/src/Functions/IFunction.cpp:420: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d95059 13. /build/src/Functions/IFunction.cpp:498: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d95c72 14. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3567: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000014034494 15. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3838: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000014019a9e 16. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3980: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000014018e31 17. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:4304: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000014042fa7 18. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5605: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000014013749 19. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000140127f9 20. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000014011fce 21. /build/src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000001406ce8a 22. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000014973b42 23. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000001497268d 24. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000014974d24 25. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001492924b 26. /build/src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88641 27. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 28. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 29. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 30. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 31. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 2025.07.28 12:03:12.231791 [ 62056 ] {} TCPHandler: Code: 43. DB::Exception: Illegal interval kind for argument data type DateTime: In scope SELECT toStartOfInterval(toDate32('2023-10-09'), toIntervalNanosecond(1), toDate32('2023-10-09')). (ILLEGAL_TYPE_OF_ARGUMENT), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type>, char const*&&) @ 0x000000000c7f5eab 4. /build/src/Functions/toStartOfInterval.cpp:306: COW::immutable_ptr DB::FunctionToStartOfInterval::dispatchForIntervalColumn>(DB::DataTypeDate32 const&, DB::ColumnVector const&, DB::ColumnWithTypeAndName const&, DB::ColumnWithTypeAndName const&, std::shared_ptr const&, DateLUTImpl const&, unsigned short) const @ 0x000000000e89448a 5. /build/src/Functions/toStartOfInterval.cpp:272: COW::immutable_ptr DB::FunctionToStartOfInterval::dispatchForTimeColumn(DB::ColumnWithTypeAndName const&, DB::ColumnWithTypeAndName const&, DB::ColumnWithTypeAndName const&, std::shared_ptr const&, DateLUTImpl const&) const @ 0x000000000e885319 6. /build/src/Functions/toStartOfInterval.cpp:245: DB::FunctionToStartOfInterval::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000e884574 7. /build/src/Functions/IFunction.h:437: DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000a069f2a 8. /build/src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000012d9965a 9. /build/src/Functions/IFunction.cpp:351: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d93b02 10. /build/src/Functions/IFunction.cpp:177: DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d93698 11. /build/src/Functions/IFunction.cpp:343: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d93aad 12. /build/src/Functions/IFunction.cpp:420: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d95059 13. /build/src/Functions/IFunction.cpp:498: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d95c72 14. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3567: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000014034494 15. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3838: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000014019a9e 16. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3980: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000014018e31 17. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:4304: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000014042fa7 18. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5605: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000014013749 19. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000140127f9 20. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000014011fce 21. /build/src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000001406ce8a 22. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000014973b42 23. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000001497268d 24. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000014974d24 25. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001492924b 26. /build/src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88641 27. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 28. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 29. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 30. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 31. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 2025.07.28 12:03:12.483764 [ 3970 ] {} test_13.rmt2 (7f9b740d-015c-470e-8cc6-8ba33be0dc63): auto DB::StorageReplicatedMergeTree::processQueueEntry(ReplicatedMergeTreeQueue::SelectedEntryPtr)::(anonymous class)::operator()(LogEntryPtr &) const: Code: 86. DB::HTTPException: Received error from remote server http://146b4357c08d:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Ftest%2F01165%2Ftest_13%2Frmt%2Freplicas%2F1&part=20250728_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.6.10636.altinitytest (altinity build)) '. (RECEIVED_ERROR_FROM_REMOTE_IO_SERVER), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.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 const&, int&&, String const&, unsigned long&&, String const&) @ 0x000000000feda8d9 4. /build/src/IO/HTTPCommon.cpp:104: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x000000000feda6e2 5. /build/src/IO/HTTPCommon.cpp:93: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x000000000feda537 6. /build/src/IO/ReadWriteBufferFromHTTP.cpp:277: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x000000001184a4c4 7. /build/src/IO/ReadWriteBufferFromHTTP.cpp:285: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x000000001184a615 8. /build/src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x000000001184ae59 9. /build/src/IO/ReadWriteBufferFromHTTP.cpp:472: void std::__function::__policy_invoker::__call_impl[abi:se190107]>(std::__function::__policy_storage const*) @ 0x000000001184cedd 10. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001184858b 11. /build/src/IO/ReadWriteBufferFromHTTP.cpp:465: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x000000001184bf0b 12. /build/src/IO/ReadBuffer.h:60: DB::ReadBuffer::next() @ 0x000000000a148c7b 13. /build/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) @ 0x0000000011849fb2 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]>&)>&, 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&) @ 0x0000000011841980 15. /build/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) @ 0x000000001621208e 16. /build/src/Storages/StorageReplicatedMergeTree.cpp:5228: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl[abi:se190107] const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000015f9a5fe 17. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000015ed8bfd 18. /build/src/Storages/StorageReplicatedMergeTree.cpp:2514: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x0000000015ec9aab 19. /build/src/Storages/StorageReplicatedMergeTree.cpp:2349: DB::StorageReplicatedMergeTree::executeLogEntry(DB::ReplicatedMergeTreeLogEntry&) @ 0x0000000015eba91b 20. /build/src/Storages/StorageReplicatedMergeTree.cpp:3876: bool std::__function::__policy_invoker&)>::__call_impl[abi:se190107])::$_1, bool (std::shared_ptr&)>>(std::__function::__policy_storage const*, std::shared_ptr&) @ 0x0000000015f9837e 21. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000165d6fc3 22. /build/src/Storages/StorageReplicatedMergeTree.cpp:3872: DB::StorageReplicatedMergeTree::processQueueEntry(std::shared_ptr) @ 0x0000000015efc18a 23. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001624c1b2 24. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000162f9c70 25. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x00000000162fa55a 26. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc6653 27. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000000fccc4c3 28. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc3d92 29. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fcca080 30. ? @ 0x00007fbc6213eac3 31. ? @ 0x00007fbc621d0850 (version 25.3.6.10636.altinitytest (altinity build)) 2025.07.28 12:03:13.293569 [ 3977 ] {} test_13.rmt2 (7f9b740d-015c-470e-8cc6-8ba33be0dc63): auto DB::StorageReplicatedMergeTree::processQueueEntry(ReplicatedMergeTreeQueue::SelectedEntryPtr)::(anonymous class)::operator()(LogEntryPtr &) const: Code: 86. DB::HTTPException: Received error from remote server http://146b4357c08d:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Ftest%2F01165%2Ftest_13%2Frmt%2Freplicas%2F1&part=20250728_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.6.10636.altinitytest (altinity build)) '. (RECEIVED_ERROR_FROM_REMOTE_IO_SERVER), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.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 const&, int&&, String const&, unsigned long&&, String const&) @ 0x000000000feda8d9 4. /build/src/IO/HTTPCommon.cpp:104: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x000000000feda6e2 5. /build/src/IO/HTTPCommon.cpp:93: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x000000000feda537 6. /build/src/IO/ReadWriteBufferFromHTTP.cpp:277: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x000000001184a4c4 7. /build/src/IO/ReadWriteBufferFromHTTP.cpp:285: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x000000001184a615 8. /build/src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x000000001184ae59 9. /build/src/IO/ReadWriteBufferFromHTTP.cpp:472: void std::__function::__policy_invoker::__call_impl[abi:se190107]>(std::__function::__policy_storage const*) @ 0x000000001184cedd 10. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001184858b 11. /build/src/IO/ReadWriteBufferFromHTTP.cpp:465: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x000000001184bf0b 12. /build/src/IO/ReadBuffer.h:60: DB::ReadBuffer::next() @ 0x000000000a148c7b 13. /build/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) @ 0x0000000011849fb2 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]>&)>&, 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&) @ 0x0000000011841980 15. /build/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) @ 0x000000001621208e 16. /build/src/Storages/StorageReplicatedMergeTree.cpp:5228: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl[abi:se190107] const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000015f9a5fe 17. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000015ed8bfd 18. /build/src/Storages/StorageReplicatedMergeTree.cpp:2514: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x0000000015ec9aab 19. /build/src/Storages/StorageReplicatedMergeTree.cpp:2349: DB::StorageReplicatedMergeTree::executeLogEntry(DB::ReplicatedMergeTreeLogEntry&) @ 0x0000000015eba91b 20. /build/src/Storages/StorageReplicatedMergeTree.cpp:3876: bool std::__function::__policy_invoker&)>::__call_impl[abi:se190107])::$_1, bool (std::shared_ptr&)>>(std::__function::__policy_storage const*, std::shared_ptr&) @ 0x0000000015f9837e 21. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000165d6fc3 22. /build/src/Storages/StorageReplicatedMergeTree.cpp:3872: DB::StorageReplicatedMergeTree::processQueueEntry(std::shared_ptr) @ 0x0000000015efc18a 23. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001624c1b2 24. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000162f9c70 25. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x00000000162fa55a 26. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc6653 27. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000000fccc4c3 28. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc3d92 29. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fcca080 30. ? @ 0x00007fbc6213eac3 31. ? @ 0x00007fbc621d0850 (version 25.3.6.10636.altinitytest (altinity build)) 2025.07.28 12:03:13.487872 [ 62056 ] {96acda2a-69e8-4dca-a29f-68fa418a1b14} executeQuery: Code: 43. DB::Exception: Illegal interval kind for argument data type DateTime: In scope SELECT toStartOfInterval(toDateTime('2023-10-09 10:11:12'), toIntervalMillisecond(1), toDateTime('2023-10-09 10:11:12')). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.6.10636.altinitytest (altinity build)) (from [::1]:51712) (comment: 02916_to_start_of_interval_with_origin.sql) (query 47, line 61) (in query: SELECT toStartOfInterval(toDateTime('2023-10-09 10:11:12'), toIntervalMillisecond(1), toDateTime('2023-10-09 10:11:12'));), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type>, char const*&&) @ 0x000000000c7f5eab 4. /build/src/Functions/toStartOfInterval.cpp:306: COW::immutable_ptr DB::FunctionToStartOfInterval::dispatchForIntervalColumn>(DB::DataTypeDateTime const&, DB::ColumnVector const&, DB::ColumnWithTypeAndName const&, DB::ColumnWithTypeAndName const&, std::shared_ptr const&, DateLUTImpl const&, unsigned short) const @ 0x000000000e8a14ca 5. /build/src/Functions/toStartOfInterval.cpp:278: COW::immutable_ptr DB::FunctionToStartOfInterval::dispatchForTimeColumn(DB::ColumnWithTypeAndName const&, DB::ColumnWithTypeAndName const&, DB::ColumnWithTypeAndName const&, std::shared_ptr const&, DateLUTImpl const&) const @ 0x000000000e8856b9 6. /build/src/Functions/toStartOfInterval.cpp:247: DB::FunctionToStartOfInterval::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000e884627 7. /build/src/Functions/IFunction.h:437: DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000a069f2a 8. /build/src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000012d9965a 9. /build/src/Functions/IFunction.cpp:351: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d93b02 10. /build/src/Functions/IFunction.cpp:177: DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d93698 11. /build/src/Functions/IFunction.cpp:343: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d93aad 12. /build/src/Functions/IFunction.cpp:420: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d95059 13. /build/src/Functions/IFunction.cpp:498: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d95c72 14. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3567: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000014034494 15. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3838: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000014019a9e 16. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3980: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000014018e31 17. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:4304: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000014042fa7 18. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5605: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000014013749 19. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000140127f9 20. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000014011fce 21. /build/src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000001406ce8a 22. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000014973b42 23. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000001497268d 24. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000014974d24 25. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001492924b 26. /build/src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88641 27. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 28. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 29. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 30. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 31. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 2025.07.28 12:03:13.491223 [ 62056 ] {} TCPHandler: Code: 43. DB::Exception: Illegal interval kind for argument data type DateTime: In scope SELECT toStartOfInterval(toDateTime('2023-10-09 10:11:12'), toIntervalMillisecond(1), toDateTime('2023-10-09 10:11:12')). (ILLEGAL_TYPE_OF_ARGUMENT), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type>, char const*&&) @ 0x000000000c7f5eab 4. /build/src/Functions/toStartOfInterval.cpp:306: COW::immutable_ptr DB::FunctionToStartOfInterval::dispatchForIntervalColumn>(DB::DataTypeDateTime const&, DB::ColumnVector const&, DB::ColumnWithTypeAndName const&, DB::ColumnWithTypeAndName const&, std::shared_ptr const&, DateLUTImpl const&, unsigned short) const @ 0x000000000e8a14ca 5. /build/src/Functions/toStartOfInterval.cpp:278: COW::immutable_ptr DB::FunctionToStartOfInterval::dispatchForTimeColumn(DB::ColumnWithTypeAndName const&, DB::ColumnWithTypeAndName const&, DB::ColumnWithTypeAndName const&, std::shared_ptr const&, DateLUTImpl const&) const @ 0x000000000e8856b9 6. /build/src/Functions/toStartOfInterval.cpp:247: DB::FunctionToStartOfInterval::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000e884627 7. /build/src/Functions/IFunction.h:437: DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000a069f2a 8. /build/src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000012d9965a 9. /build/src/Functions/IFunction.cpp:351: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d93b02 10. /build/src/Functions/IFunction.cpp:177: DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d93698 11. /build/src/Functions/IFunction.cpp:343: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d93aad 12. /build/src/Functions/IFunction.cpp:420: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d95059 13. /build/src/Functions/IFunction.cpp:498: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d95c72 14. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3567: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000014034494 15. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3838: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000014019a9e 16. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3980: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000014018e31 17. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:4304: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000014042fa7 18. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5605: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000014013749 19. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000140127f9 20. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000014011fce 21. /build/src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000001406ce8a 22. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000014973b42 23. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000001497268d 24. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000014974d24 25. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001492924b 26. /build/src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88641 27. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 28. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 29. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 30. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 31. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 2025.07.28 12:03:13.609997 [ 62056 ] {7b47e49b-31cb-4ace-83b5-44700422d019} executeQuery: Code: 43. DB::Exception: Illegal interval kind for argument data type DateTime: In scope SELECT toStartOfInterval(toDateTime('2023-10-09 10:11:12'), toIntervalMicrosecond(1), toDateTime('2023-10-09 10:11:12')). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.6.10636.altinitytest (altinity build)) (from [::1]:51712) (comment: 02916_to_start_of_interval_with_origin.sql) (query 48, line 62) (in query: SELECT toStartOfInterval(toDateTime('2023-10-09 10:11:12'), toIntervalMicrosecond(1), toDateTime('2023-10-09 10:11:12'));), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type>, char const*&&) @ 0x000000000c7f5eab 4. /build/src/Functions/toStartOfInterval.cpp:306: COW::immutable_ptr DB::FunctionToStartOfInterval::dispatchForIntervalColumn>(DB::DataTypeDateTime const&, DB::ColumnVector const&, DB::ColumnWithTypeAndName const&, DB::ColumnWithTypeAndName const&, std::shared_ptr const&, DateLUTImpl const&, unsigned short) const @ 0x000000000e8a14ca 5. /build/src/Functions/toStartOfInterval.cpp:278: COW::immutable_ptr DB::FunctionToStartOfInterval::dispatchForTimeColumn(DB::ColumnWithTypeAndName const&, DB::ColumnWithTypeAndName const&, DB::ColumnWithTypeAndName const&, std::shared_ptr const&, DateLUTImpl const&) const @ 0x000000000e8856b9 6. /build/src/Functions/toStartOfInterval.cpp:247: DB::FunctionToStartOfInterval::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000e884627 7. /build/src/Functions/IFunction.h:437: DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000a069f2a 8. /build/src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000012d9965a 9. /build/src/Functions/IFunction.cpp:351: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d93b02 10. /build/src/Functions/IFunction.cpp:177: DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d93698 11. /build/src/Functions/IFunction.cpp:343: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d93aad 12. /build/src/Functions/IFunction.cpp:420: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d95059 13. /build/src/Functions/IFunction.cpp:498: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d95c72 14. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3567: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000014034494 15. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3838: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000014019a9e 16. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3980: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000014018e31 17. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:4304: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000014042fa7 18. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5605: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000014013749 19. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000140127f9 20. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000014011fce 21. /build/src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000001406ce8a 22. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000014973b42 23. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000001497268d 24. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000014974d24 25. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001492924b 26. /build/src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88641 27. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 28. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 29. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 30. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 31. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 2025.07.28 12:03:13.613496 [ 62056 ] {} TCPHandler: Code: 43. DB::Exception: Illegal interval kind for argument data type DateTime: In scope SELECT toStartOfInterval(toDateTime('2023-10-09 10:11:12'), toIntervalMicrosecond(1), toDateTime('2023-10-09 10:11:12')). (ILLEGAL_TYPE_OF_ARGUMENT), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type>, char const*&&) @ 0x000000000c7f5eab 4. /build/src/Functions/toStartOfInterval.cpp:306: COW::immutable_ptr DB::FunctionToStartOfInterval::dispatchForIntervalColumn>(DB::DataTypeDateTime const&, DB::ColumnVector const&, DB::ColumnWithTypeAndName const&, DB::ColumnWithTypeAndName const&, std::shared_ptr const&, DateLUTImpl const&, unsigned short) const @ 0x000000000e8a14ca 5. /build/src/Functions/toStartOfInterval.cpp:278: COW::immutable_ptr DB::FunctionToStartOfInterval::dispatchForTimeColumn(DB::ColumnWithTypeAndName const&, DB::ColumnWithTypeAndName const&, DB::ColumnWithTypeAndName const&, std::shared_ptr const&, DateLUTImpl const&) const @ 0x000000000e8856b9 6. /build/src/Functions/toStartOfInterval.cpp:247: DB::FunctionToStartOfInterval::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000e884627 7. /build/src/Functions/IFunction.h:437: DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000a069f2a 8. /build/src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000012d9965a 9. /build/src/Functions/IFunction.cpp:351: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d93b02 10. /build/src/Functions/IFunction.cpp:177: DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d93698 11. /build/src/Functions/IFunction.cpp:343: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d93aad 12. /build/src/Functions/IFunction.cpp:420: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d95059 13. /build/src/Functions/IFunction.cpp:498: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d95c72 14. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3567: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000014034494 15. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3838: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000014019a9e 16. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3980: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000014018e31 17. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:4304: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000014042fa7 18. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5605: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000014013749 19. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000140127f9 20. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000014011fce 21. /build/src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000001406ce8a 22. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000014973b42 23. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000001497268d 24. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000014974d24 25. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001492924b 26. /build/src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88641 27. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 28. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 29. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 30. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 31. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 2025.07.28 12:03:13.663200 [ 62056 ] {24d70b9f-bc5f-46a4-ade3-f6b17f75e2c6} executeQuery: Code: 43. DB::Exception: Illegal interval kind for argument data type DateTime: In scope SELECT toStartOfInterval(toDateTime('2023-10-09 10:11:12'), toIntervalNanosecond(1), toDateTime('2023-10-09 10:11:12')). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.6.10636.altinitytest (altinity build)) (from [::1]:51712) (comment: 02916_to_start_of_interval_with_origin.sql) (query 49, line 63) (in query: SELECT toStartOfInterval(toDateTime('2023-10-09 10:11:12'), toIntervalNanosecond(1), toDateTime('2023-10-09 10:11:12'));), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type>, char const*&&) @ 0x000000000c7f5eab 4. /build/src/Functions/toStartOfInterval.cpp:306: COW::immutable_ptr DB::FunctionToStartOfInterval::dispatchForIntervalColumn>(DB::DataTypeDateTime const&, DB::ColumnVector const&, DB::ColumnWithTypeAndName const&, DB::ColumnWithTypeAndName const&, std::shared_ptr const&, DateLUTImpl const&, unsigned short) const @ 0x000000000e8a14ca 5. /build/src/Functions/toStartOfInterval.cpp:278: COW::immutable_ptr DB::FunctionToStartOfInterval::dispatchForTimeColumn(DB::ColumnWithTypeAndName const&, DB::ColumnWithTypeAndName const&, DB::ColumnWithTypeAndName const&, std::shared_ptr const&, DateLUTImpl const&) const @ 0x000000000e8856b9 6. /build/src/Functions/toStartOfInterval.cpp:247: DB::FunctionToStartOfInterval::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000e884627 7. /build/src/Functions/IFunction.h:437: DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000a069f2a 8. /build/src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000012d9965a 9. /build/src/Functions/IFunction.cpp:351: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d93b02 10. /build/src/Functions/IFunction.cpp:177: DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d93698 11. /build/src/Functions/IFunction.cpp:343: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d93aad 12. /build/src/Functions/IFunction.cpp:420: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d95059 13. /build/src/Functions/IFunction.cpp:498: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d95c72 14. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3567: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000014034494 15. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3838: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000014019a9e 16. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3980: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000014018e31 17. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:4304: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000014042fa7 18. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5605: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000014013749 19. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000140127f9 20. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000014011fce 21. /build/src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000001406ce8a 22. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000014973b42 23. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000001497268d 24. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000014974d24 25. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001492924b 26. /build/src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88641 27. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 28. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 29. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 30. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 31. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 2025.07.28 12:03:13.677657 [ 62056 ] {} TCPHandler: Code: 43. DB::Exception: Illegal interval kind for argument data type DateTime: In scope SELECT toStartOfInterval(toDateTime('2023-10-09 10:11:12'), toIntervalNanosecond(1), toDateTime('2023-10-09 10:11:12')). (ILLEGAL_TYPE_OF_ARGUMENT), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type>, char const*&&) @ 0x000000000c7f5eab 4. /build/src/Functions/toStartOfInterval.cpp:306: COW::immutable_ptr DB::FunctionToStartOfInterval::dispatchForIntervalColumn>(DB::DataTypeDateTime const&, DB::ColumnVector const&, DB::ColumnWithTypeAndName const&, DB::ColumnWithTypeAndName const&, std::shared_ptr const&, DateLUTImpl const&, unsigned short) const @ 0x000000000e8a14ca 5. /build/src/Functions/toStartOfInterval.cpp:278: COW::immutable_ptr DB::FunctionToStartOfInterval::dispatchForTimeColumn(DB::ColumnWithTypeAndName const&, DB::ColumnWithTypeAndName const&, DB::ColumnWithTypeAndName const&, std::shared_ptr const&, DateLUTImpl const&) const @ 0x000000000e8856b9 6. /build/src/Functions/toStartOfInterval.cpp:247: DB::FunctionToStartOfInterval::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000e884627 7. /build/src/Functions/IFunction.h:437: DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000a069f2a 8. /build/src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000012d9965a 9. /build/src/Functions/IFunction.cpp:351: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d93b02 10. /build/src/Functions/IFunction.cpp:177: DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d93698 11. /build/src/Functions/IFunction.cpp:343: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d93aad 12. /build/src/Functions/IFunction.cpp:420: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d95059 13. /build/src/Functions/IFunction.cpp:498: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d95c72 14. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3567: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000014034494 15. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3838: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000014019a9e 16. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3980: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000014018e31 17. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:4304: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000014042fa7 18. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5605: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000014013749 19. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000140127f9 20. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000014011fce 21. /build/src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000001406ce8a 22. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000014973b42 23. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000001497268d 24. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000014974d24 25. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001492924b 26. /build/src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88641 27. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 28. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 29. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 30. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 31. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 2025.07.28 12:03:14.298005 [ 3965 ] {} test_13.rmt2 (7f9b740d-015c-470e-8cc6-8ba33be0dc63): auto DB::StorageReplicatedMergeTree::processQueueEntry(ReplicatedMergeTreeQueue::SelectedEntryPtr)::(anonymous class)::operator()(LogEntryPtr &) const: Code: 86. DB::HTTPException: Received error from remote server http://146b4357c08d:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Ftest%2F01165%2Ftest_13%2Frmt%2Freplicas%2F1&part=20250728_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.6.10636.altinitytest (altinity build)) '. (RECEIVED_ERROR_FROM_REMOTE_IO_SERVER), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.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 const&, int&&, String const&, unsigned long&&, String const&) @ 0x000000000feda8d9 4. /build/src/IO/HTTPCommon.cpp:104: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x000000000feda6e2 5. /build/src/IO/HTTPCommon.cpp:93: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x000000000feda537 6. /build/src/IO/ReadWriteBufferFromHTTP.cpp:277: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x000000001184a4c4 7. /build/src/IO/ReadWriteBufferFromHTTP.cpp:285: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x000000001184a615 8. /build/src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x000000001184ae59 9. /build/src/IO/ReadWriteBufferFromHTTP.cpp:472: void std::__function::__policy_invoker::__call_impl[abi:se190107]>(std::__function::__policy_storage const*) @ 0x000000001184cedd 10. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001184858b 11. /build/src/IO/ReadWriteBufferFromHTTP.cpp:465: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x000000001184bf0b 12. /build/src/IO/ReadBuffer.h:60: DB::ReadBuffer::next() @ 0x000000000a148c7b 13. /build/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) @ 0x0000000011849fb2 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]>&)>&, 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&) @ 0x0000000011841980 15. /build/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) @ 0x000000001621208e 16. /build/src/Storages/StorageReplicatedMergeTree.cpp:5228: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl[abi:se190107] const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000015f9a5fe 17. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000015ed8bfd 18. /build/src/Storages/StorageReplicatedMergeTree.cpp:2514: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x0000000015ec9aab 19. /build/src/Storages/StorageReplicatedMergeTree.cpp:2349: DB::StorageReplicatedMergeTree::executeLogEntry(DB::ReplicatedMergeTreeLogEntry&) @ 0x0000000015eba91b 20. /build/src/Storages/StorageReplicatedMergeTree.cpp:3876: bool std::__function::__policy_invoker&)>::__call_impl[abi:se190107])::$_1, bool (std::shared_ptr&)>>(std::__function::__policy_storage const*, std::shared_ptr&) @ 0x0000000015f9837e 21. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000165d6fc3 22. /build/src/Storages/StorageReplicatedMergeTree.cpp:3872: DB::StorageReplicatedMergeTree::processQueueEntry(std::shared_ptr) @ 0x0000000015efc18a 23. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001624c1b2 24. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000162f9c70 25. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x00000000162fa55a 26. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc6653 27. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000000fccc4c3 28. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc3d92 29. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fcca080 30. ? @ 0x00007fbc6213eac3 31. ? @ 0x00007fbc621d0850 (version 25.3.6.10636.altinitytest (altinity build)) 2025.07.28 12:03:15.207151 [ 3963 ] {} test_13.rmt2 (7f9b740d-015c-470e-8cc6-8ba33be0dc63): auto DB::StorageReplicatedMergeTree::processQueueEntry(ReplicatedMergeTreeQueue::SelectedEntryPtr)::(anonymous class)::operator()(LogEntryPtr &) const: Code: 86. DB::HTTPException: Received error from remote server http://146b4357c08d:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Ftest%2F01165%2Ftest_13%2Frmt%2Freplicas%2F1&part=20250728_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.6.10636.altinitytest (altinity build)) '. (RECEIVED_ERROR_FROM_REMOTE_IO_SERVER), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.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 const&, int&&, String const&, unsigned long&&, String const&) @ 0x000000000feda8d9 4. /build/src/IO/HTTPCommon.cpp:104: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x000000000feda6e2 5. /build/src/IO/HTTPCommon.cpp:93: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x000000000feda537 6. /build/src/IO/ReadWriteBufferFromHTTP.cpp:277: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x000000001184a4c4 7. /build/src/IO/ReadWriteBufferFromHTTP.cpp:285: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x000000001184a615 8. /build/src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x000000001184ae59 9. /build/src/IO/ReadWriteBufferFromHTTP.cpp:472: void std::__function::__policy_invoker::__call_impl[abi:se190107]>(std::__function::__policy_storage const*) @ 0x000000001184cedd 10. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001184858b 11. /build/src/IO/ReadWriteBufferFromHTTP.cpp:465: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x000000001184bf0b 12. /build/src/IO/ReadBuffer.h:60: DB::ReadBuffer::next() @ 0x000000000a148c7b 13. /build/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) @ 0x0000000011849fb2 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]>&)>&, 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&) @ 0x0000000011841980 15. /build/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) @ 0x000000001621208e 16. /build/src/Storages/StorageReplicatedMergeTree.cpp:5228: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl[abi:se190107] const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000015f9a5fe 17. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000015ed8bfd 18. /build/src/Storages/StorageReplicatedMergeTree.cpp:2514: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x0000000015ec9aab 19. /build/src/Storages/StorageReplicatedMergeTree.cpp:2349: DB::StorageReplicatedMergeTree::executeLogEntry(DB::ReplicatedMergeTreeLogEntry&) @ 0x0000000015eba91b 20. /build/src/Storages/StorageReplicatedMergeTree.cpp:3876: bool std::__function::__policy_invoker&)>::__call_impl[abi:se190107])::$_1, bool (std::shared_ptr&)>>(std::__function::__policy_storage const*, std::shared_ptr&) @ 0x0000000015f9837e 21. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000165d6fc3 22. /build/src/Storages/StorageReplicatedMergeTree.cpp:3872: DB::StorageReplicatedMergeTree::processQueueEntry(std::shared_ptr) @ 0x0000000015efc18a 23. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001624c1b2 24. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000162f9c70 25. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x00000000162fa55a 26. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc6653 27. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000000fccc4c3 28. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc3d92 29. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fcca080 30. ? @ 0x00007fbc6213eac3 31. ? @ 0x00007fbc621d0850 (version 25.3.6.10636.altinitytest (altinity build)) 2025.07.28 12:03:15.516051 [ 3962 ] {} test_13.rmt2 (7f9b740d-015c-470e-8cc6-8ba33be0dc63): auto DB::StorageReplicatedMergeTree::processQueueEntry(ReplicatedMergeTreeQueue::SelectedEntryPtr)::(anonymous class)::operator()(LogEntryPtr &) const: Code: 86. DB::HTTPException: Received error from remote server http://146b4357c08d:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Ftest%2F01165%2Ftest_13%2Frmt%2Freplicas%2F1&part=20250728_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.6.10636.altinitytest (altinity build)) '. (RECEIVED_ERROR_FROM_REMOTE_IO_SERVER), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.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 const&, int&&, String const&, unsigned long&&, String const&) @ 0x000000000feda8d9 4. /build/src/IO/HTTPCommon.cpp:104: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x000000000feda6e2 5. /build/src/IO/HTTPCommon.cpp:93: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x000000000feda537 6. /build/src/IO/ReadWriteBufferFromHTTP.cpp:277: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x000000001184a4c4 7. /build/src/IO/ReadWriteBufferFromHTTP.cpp:285: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x000000001184a615 8. /build/src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x000000001184ae59 9. /build/src/IO/ReadWriteBufferFromHTTP.cpp:472: void std::__function::__policy_invoker::__call_impl[abi:se190107]>(std::__function::__policy_storage const*) @ 0x000000001184cedd 10. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001184858b 11. /build/src/IO/ReadWriteBufferFromHTTP.cpp:465: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x000000001184bf0b 12. /build/src/IO/ReadBuffer.h:60: DB::ReadBuffer::next() @ 0x000000000a148c7b 13. /build/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) @ 0x0000000011849fb2 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]>&)>&, 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&) @ 0x0000000011841980 15. /build/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) @ 0x000000001621208e 16. /build/src/Storages/StorageReplicatedMergeTree.cpp:5228: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl[abi:se190107] const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000015f9a5fe 17. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000015ed8bfd 18. /build/src/Storages/StorageReplicatedMergeTree.cpp:2514: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x0000000015ec9aab 19. /build/src/Storages/StorageReplicatedMergeTree.cpp:2349: DB::StorageReplicatedMergeTree::executeLogEntry(DB::ReplicatedMergeTreeLogEntry&) @ 0x0000000015eba91b 20. /build/src/Storages/StorageReplicatedMergeTree.cpp:3876: bool std::__function::__policy_invoker&)>::__call_impl[abi:se190107])::$_1, bool (std::shared_ptr&)>>(std::__function::__policy_storage const*, std::shared_ptr&) @ 0x0000000015f9837e 21. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000165d6fc3 22. /build/src/Storages/StorageReplicatedMergeTree.cpp:3872: DB::StorageReplicatedMergeTree::processQueueEntry(std::shared_ptr) @ 0x0000000015efc18a 23. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001624c1b2 24. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000162f9c70 25. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x00000000162fa55a 26. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc6653 27. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000000fccc4c3 28. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc3d92 29. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fcca080 30. ? @ 0x00007fbc6213eac3 31. ? @ 0x00007fbc621d0850 (version 25.3.6.10636.altinitytest (altinity build)) 2025.07.28 12:03:16.352939 [ 3977 ] {} test_13.rmt2 (7f9b740d-015c-470e-8cc6-8ba33be0dc63): auto DB::StorageReplicatedMergeTree::processQueueEntry(ReplicatedMergeTreeQueue::SelectedEntryPtr)::(anonymous class)::operator()(LogEntryPtr &) const: Code: 86. DB::HTTPException: Received error from remote server http://146b4357c08d:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Ftest%2F01165%2Ftest_13%2Frmt%2Freplicas%2F1&part=20250728_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.6.10636.altinitytest (altinity build)) '. (RECEIVED_ERROR_FROM_REMOTE_IO_SERVER), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.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 const&, int&&, String const&, unsigned long&&, String const&) @ 0x000000000feda8d9 4. /build/src/IO/HTTPCommon.cpp:104: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x000000000feda6e2 5. /build/src/IO/HTTPCommon.cpp:93: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x000000000feda537 6. /build/src/IO/ReadWriteBufferFromHTTP.cpp:277: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x000000001184a4c4 7. /build/src/IO/ReadWriteBufferFromHTTP.cpp:285: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x000000001184a615 8. /build/src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x000000001184ae59 9. /build/src/IO/ReadWriteBufferFromHTTP.cpp:472: void std::__function::__policy_invoker::__call_impl[abi:se190107]>(std::__function::__policy_storage const*) @ 0x000000001184cedd 10. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001184858b 11. /build/src/IO/ReadWriteBufferFromHTTP.cpp:465: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x000000001184bf0b 12. /build/src/IO/ReadBuffer.h:60: DB::ReadBuffer::next() @ 0x000000000a148c7b 13. /build/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) @ 0x0000000011849fb2 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]>&)>&, 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&) @ 0x0000000011841980 15. /build/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) @ 0x000000001621208e 16. /build/src/Storages/StorageReplicatedMergeTree.cpp:5228: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl[abi:se190107] const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000015f9a5fe 17. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000015ed8bfd 18. /build/src/Storages/StorageReplicatedMergeTree.cpp:2514: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x0000000015ec9aab 19. /build/src/Storages/StorageReplicatedMergeTree.cpp:2349: DB::StorageReplicatedMergeTree::executeLogEntry(DB::ReplicatedMergeTreeLogEntry&) @ 0x0000000015eba91b 20. /build/src/Storages/StorageReplicatedMergeTree.cpp:3876: bool std::__function::__policy_invoker&)>::__call_impl[abi:se190107])::$_1, bool (std::shared_ptr&)>>(std::__function::__policy_storage const*, std::shared_ptr&) @ 0x0000000015f9837e 21. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000165d6fc3 22. /build/src/Storages/StorageReplicatedMergeTree.cpp:3872: DB::StorageReplicatedMergeTree::processQueueEntry(std::shared_ptr) @ 0x0000000015efc18a 23. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001624c1b2 24. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000162f9c70 25. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x00000000162fa55a 26. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc6653 27. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000000fccc4c3 28. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc3d92 29. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fcca080 30. ? @ 0x00007fbc6213eac3 31. ? @ 0x00007fbc621d0850 (version 25.3.6.10636.altinitytest (altinity build)) 2025.07.28 12:03:16.568128 [ 3976 ] {} test_13.rmt2 (7f9b740d-015c-470e-8cc6-8ba33be0dc63): auto DB::StorageReplicatedMergeTree::processQueueEntry(ReplicatedMergeTreeQueue::SelectedEntryPtr)::(anonymous class)::operator()(LogEntryPtr &) const: Code: 86. DB::HTTPException: Received error from remote server http://146b4357c08d:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Ftest%2F01165%2Ftest_13%2Frmt%2Freplicas%2F1&part=20250728_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.6.10636.altinitytest (altinity build)) '. (RECEIVED_ERROR_FROM_REMOTE_IO_SERVER), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.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 const&, int&&, String const&, unsigned long&&, String const&) @ 0x000000000feda8d9 4. /build/src/IO/HTTPCommon.cpp:104: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x000000000feda6e2 5. /build/src/IO/HTTPCommon.cpp:93: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x000000000feda537 6. /build/src/IO/ReadWriteBufferFromHTTP.cpp:277: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x000000001184a4c4 7. /build/src/IO/ReadWriteBufferFromHTTP.cpp:285: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x000000001184a615 8. /build/src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x000000001184ae59 9. /build/src/IO/ReadWriteBufferFromHTTP.cpp:472: void std::__function::__policy_invoker::__call_impl[abi:se190107]>(std::__function::__policy_storage const*) @ 0x000000001184cedd 10. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001184858b 11. /build/src/IO/ReadWriteBufferFromHTTP.cpp:465: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x000000001184bf0b 12. /build/src/IO/ReadBuffer.h:60: DB::ReadBuffer::next() @ 0x000000000a148c7b 13. /build/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) @ 0x0000000011849fb2 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]>&)>&, 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&) @ 0x0000000011841980 15. /build/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) @ 0x000000001621208e 16. /build/src/Storages/StorageReplicatedMergeTree.cpp:5228: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl[abi:se190107] const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000015f9a5fe 17. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000015ed8bfd 18. /build/src/Storages/StorageReplicatedMergeTree.cpp:2514: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x0000000015ec9aab 19. /build/src/Storages/StorageReplicatedMergeTree.cpp:2349: DB::StorageReplicatedMergeTree::executeLogEntry(DB::ReplicatedMergeTreeLogEntry&) @ 0x0000000015eba91b 20. /build/src/Storages/StorageReplicatedMergeTree.cpp:3876: bool std::__function::__policy_invoker&)>::__call_impl[abi:se190107])::$_1, bool (std::shared_ptr&)>>(std::__function::__policy_storage const*, std::shared_ptr&) @ 0x0000000015f9837e 21. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000165d6fc3 22. /build/src/Storages/StorageReplicatedMergeTree.cpp:3872: DB::StorageReplicatedMergeTree::processQueueEntry(std::shared_ptr) @ 0x0000000015efc18a 23. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001624c1b2 24. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000162f9c70 25. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x00000000162fa55a 26. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc6653 27. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000000fccc4c3 28. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc3d92 29. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fcca080 30. ? @ 0x00007fbc6213eac3 31. ? @ 0x00007fbc621d0850 (version 25.3.6.10636.altinitytest (altinity build)) 2025.07.28 12:03:16.988996 [ 62075 ] {211fc96c-0857-4944-a3d6-ef9f3c21a154} executeQuery: Code: 141. DB::Exception: Storage test_9.modify_sample doesn't support sampling. (SAMPLING_NOT_SUPPORTED) (version 25.3.6.10636.altinitytest (altinity build)) (from [::1]:60896) (comment: 01430_modify_sample_by_zookeeper_long.sql) (query 6, line 11) (in query: SELECT count(), min(x), max(x), sum(x), uniqExact(x) FROM modify_sample SAMPLE 0.1;), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x000000000a06b56b 4. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:920: DB::QueryAnalyzer::validateTableExpressionModifiers(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000014016fc9 5. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5383: DB::QueryAnalyzer::resolveQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&) @ 0x00000000140457dd 6. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5597: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000140136f0 7. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000140127f9 8. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000014011fce 9. /build/src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000001406ce8a 10. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000014973b42 11. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000001497268d 12. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000014974d24 13. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001492924b 14. /build/src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88641 15. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 16. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 17. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 18. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 19. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 20. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 21. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 22. ? @ 0x00007fbc6213eac3 23. ? @ 0x00007fbc621d0850 2025.07.28 12:03:16.994757 [ 62075 ] {} TCPHandler: Code: 141. DB::Exception: Storage test_9.modify_sample doesn't support sampling. (SAMPLING_NOT_SUPPORTED), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x000000000a06b56b 4. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:920: DB::QueryAnalyzer::validateTableExpressionModifiers(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000014016fc9 5. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5383: DB::QueryAnalyzer::resolveQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&) @ 0x00000000140457dd 6. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5597: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000140136f0 7. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000140127f9 8. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000014011fce 9. /build/src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000001406ce8a 10. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000014973b42 11. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000001497268d 12. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000014974d24 13. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001492924b 14. /build/src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88641 15. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 16. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 17. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 18. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 19. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 20. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 21. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 22. ? @ 0x00007fbc6213eac3 23. ? @ 0x00007fbc621d0850 2025.07.28 12:03:17.313655 [ 3970 ] {} test_13.rmt2 (7f9b740d-015c-470e-8cc6-8ba33be0dc63): auto DB::StorageReplicatedMergeTree::processQueueEntry(ReplicatedMergeTreeQueue::SelectedEntryPtr)::(anonymous class)::operator()(LogEntryPtr &) const: Code: 86. DB::HTTPException: Received error from remote server http://146b4357c08d:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Ftest%2F01165%2Ftest_13%2Frmt%2Freplicas%2F1&part=20250728_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.6.10636.altinitytest (altinity build)) '. (RECEIVED_ERROR_FROM_REMOTE_IO_SERVER), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.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 const&, int&&, String const&, unsigned long&&, String const&) @ 0x000000000feda8d9 4. /build/src/IO/HTTPCommon.cpp:104: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x000000000feda6e2 5. /build/src/IO/HTTPCommon.cpp:93: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x000000000feda537 6. /build/src/IO/ReadWriteBufferFromHTTP.cpp:277: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x000000001184a4c4 7. /build/src/IO/ReadWriteBufferFromHTTP.cpp:285: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x000000001184a615 8. /build/src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x000000001184ae59 9. /build/src/IO/ReadWriteBufferFromHTTP.cpp:472: void std::__function::__policy_invoker::__call_impl[abi:se190107]>(std::__function::__policy_storage const*) @ 0x000000001184cedd 10. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001184858b 11. /build/src/IO/ReadWriteBufferFromHTTP.cpp:465: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x000000001184bf0b 12. /build/src/IO/ReadBuffer.h:60: DB::ReadBuffer::next() @ 0x000000000a148c7b 13. /build/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) @ 0x0000000011849fb2 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]>&)>&, 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&) @ 0x0000000011841980 15. /build/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) @ 0x000000001621208e 16. /build/src/Storages/StorageReplicatedMergeTree.cpp:5228: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl[abi:se190107] const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000015f9a5fe 17. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000015ed8bfd 18. /build/src/Storages/StorageReplicatedMergeTree.cpp:2514: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x0000000015ec9aab 19. /build/src/Storages/StorageReplicatedMergeTree.cpp:2349: DB::StorageReplicatedMergeTree::executeLogEntry(DB::ReplicatedMergeTreeLogEntry&) @ 0x0000000015eba91b 20. /build/src/Storages/StorageReplicatedMergeTree.cpp:3876: bool std::__function::__policy_invoker&)>::__call_impl[abi:se190107])::$_1, bool (std::shared_ptr&)>>(std::__function::__policy_storage const*, std::shared_ptr&) @ 0x0000000015f9837e 21. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000165d6fc3 22. /build/src/Storages/StorageReplicatedMergeTree.cpp:3872: DB::StorageReplicatedMergeTree::processQueueEntry(std::shared_ptr) @ 0x0000000015efc18a 23. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001624c1b2 24. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000162f9c70 25. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x00000000162fa55a 26. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc6653 27. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000000fccc4c3 28. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc3d92 29. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fcca080 30. ? @ 0x00007fbc6213eac3 31. ? @ 0x00007fbc621d0850 (version 25.3.6.10636.altinitytest (altinity build)) 2025.07.28 12:03:17.480054 [ 3971 ] {} test_13.rmt2 (7f9b740d-015c-470e-8cc6-8ba33be0dc63): auto DB::StorageReplicatedMergeTree::processQueueEntry(ReplicatedMergeTreeQueue::SelectedEntryPtr)::(anonymous class)::operator()(LogEntryPtr &) const: Code: 86. DB::HTTPException: Received error from remote server http://146b4357c08d:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Ftest%2F01165%2Ftest_13%2Frmt%2Freplicas%2F1&part=20250728_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.6.10636.altinitytest (altinity build)) '. (RECEIVED_ERROR_FROM_REMOTE_IO_SERVER), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.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 const&, int&&, String const&, unsigned long&&, String const&) @ 0x000000000feda8d9 4. /build/src/IO/HTTPCommon.cpp:104: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x000000000feda6e2 5. /build/src/IO/HTTPCommon.cpp:93: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x000000000feda537 6. /build/src/IO/ReadWriteBufferFromHTTP.cpp:277: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x000000001184a4c4 7. /build/src/IO/ReadWriteBufferFromHTTP.cpp:285: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x000000001184a615 8. /build/src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x000000001184ae59 9. /build/src/IO/ReadWriteBufferFromHTTP.cpp:472: void std::__function::__policy_invoker::__call_impl[abi:se190107]>(std::__function::__policy_storage const*) @ 0x000000001184cedd 10. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001184858b 11. /build/src/IO/ReadWriteBufferFromHTTP.cpp:465: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x000000001184bf0b 12. /build/src/IO/ReadBuffer.h:60: DB::ReadBuffer::next() @ 0x000000000a148c7b 13. /build/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) @ 0x0000000011849fb2 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]>&)>&, 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&) @ 0x0000000011841980 15. /build/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) @ 0x000000001621208e 16. /build/src/Storages/StorageReplicatedMergeTree.cpp:5228: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl[abi:se190107] const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000015f9a5fe 17. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000015ed8bfd 18. /build/src/Storages/StorageReplicatedMergeTree.cpp:2514: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x0000000015ec9aab 19. /build/src/Storages/StorageReplicatedMergeTree.cpp:2349: DB::StorageReplicatedMergeTree::executeLogEntry(DB::ReplicatedMergeTreeLogEntry&) @ 0x0000000015eba91b 20. /build/src/Storages/StorageReplicatedMergeTree.cpp:3876: bool std::__function::__policy_invoker&)>::__call_impl[abi:se190107])::$_1, bool (std::shared_ptr&)>>(std::__function::__policy_storage const*, std::shared_ptr&) @ 0x0000000015f9837e 21. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000165d6fc3 22. /build/src/Storages/StorageReplicatedMergeTree.cpp:3872: DB::StorageReplicatedMergeTree::processQueueEntry(std::shared_ptr) @ 0x0000000015efc18a 23. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001624c1b2 24. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000162f9c70 25. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x00000000162fa55a 26. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc6653 27. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000000fccc4c3 28. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc3d92 29. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fcca080 30. ? @ 0x00007fbc6213eac3 31. ? @ 0x00007fbc621d0850 (version 25.3.6.10636.altinitytest (altinity build)) 2025.07.28 12:03:17.625892 [ 3967 ] {} test_13.rmt2 (7f9b740d-015c-470e-8cc6-8ba33be0dc63): auto DB::StorageReplicatedMergeTree::processQueueEntry(ReplicatedMergeTreeQueue::SelectedEntryPtr)::(anonymous class)::operator()(LogEntryPtr &) const: Code: 86. DB::HTTPException: Received error from remote server http://146b4357c08d:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Ftest%2F01165%2Ftest_13%2Frmt%2Freplicas%2F1&part=20250728_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.6.10636.altinitytest (altinity build)) '. (RECEIVED_ERROR_FROM_REMOTE_IO_SERVER), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.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 const&, int&&, String const&, unsigned long&&, String const&) @ 0x000000000feda8d9 4. /build/src/IO/HTTPCommon.cpp:104: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x000000000feda6e2 5. /build/src/IO/HTTPCommon.cpp:93: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x000000000feda537 6. /build/src/IO/ReadWriteBufferFromHTTP.cpp:277: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x000000001184a4c4 7. /build/src/IO/ReadWriteBufferFromHTTP.cpp:285: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x000000001184a615 8. /build/src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x000000001184ae59 9. /build/src/IO/ReadWriteBufferFromHTTP.cpp:472: void std::__function::__policy_invoker::__call_impl[abi:se190107]>(std::__function::__policy_storage const*) @ 0x000000001184cedd 10. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001184858b 11. /build/src/IO/ReadWriteBufferFromHTTP.cpp:465: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x000000001184bf0b 12. /build/src/IO/ReadBuffer.h:60: DB::ReadBuffer::next() @ 0x000000000a148c7b 13. /build/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) @ 0x0000000011849fb2 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]>&)>&, 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&) @ 0x0000000011841980 15. /build/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) @ 0x000000001621208e 16. /build/src/Storages/StorageReplicatedMergeTree.cpp:5228: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl[abi:se190107] const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000015f9a5fe 17. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000015ed8bfd 18. /build/src/Storages/StorageReplicatedMergeTree.cpp:2514: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x0000000015ec9aab 19. /build/src/Storages/StorageReplicatedMergeTree.cpp:2349: DB::StorageReplicatedMergeTree::executeLogEntry(DB::ReplicatedMergeTreeLogEntry&) @ 0x0000000015eba91b 20. /build/src/Storages/StorageReplicatedMergeTree.cpp:3876: bool std::__function::__policy_invoker&)>::__call_impl[abi:se190107])::$_1, bool (std::shared_ptr&)>>(std::__function::__policy_storage const*, std::shared_ptr&) @ 0x0000000015f9837e 21. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000165d6fc3 22. /build/src/Storages/StorageReplicatedMergeTree.cpp:3872: DB::StorageReplicatedMergeTree::processQueueEntry(std::shared_ptr) @ 0x0000000015efc18a 23. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001624c1b2 24. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000162f9c70 25. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x00000000162fa55a 26. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc6653 27. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000000fccc4c3 28. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc3d92 29. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fcca080 30. ? @ 0x00007fbc6213eac3 31. ? @ 0x00007fbc621d0850 (version 25.3.6.10636.altinitytest (altinity build)) 2025.07.28 12:03:17.819033 [ 17203 ] {e181b510-d09c-40a7-992a-eac873caf82c} executeQuery: Code: 43. DB::Exception: Illegal types Decimal(6, 4) and Decimal(6, 4) of arguments for aggregate function covarPop. (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.6.10636.altinitytest (altinity build)) (from [::1]:51760) (comment: 00700_decimal_empty_aggregates.sql) (query 58, line 80) (in query: SELECT covarPop(a, a), covarPop(b, b), covarPop(c, c) FROM decimal;), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String const&) @ 0x000000001011aceb 4. /build/src/AggregateFunctions/AggregateFunctionStatisticsSimple.h:266: std::shared_ptr DB::createAggregateFunctionStatisticsBinary(String const&, std::vector, std::allocator>> const&, DB::Array const&, DB::Settings const*) @ 0x0000000010c906fa 5. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000131e00dd 6. /build/src/AggregateFunctions/AggregateFunctionFactory.cpp:130: DB::AggregateFunctionFactory::get(String const&, DB::NullsAction, std::vector, std::allocator>> const&, DB::Array const&, DB::AggregateFunctionProperties&) const @ 0x00000000131df0ca 7. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3368: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000014032fed 8. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3838: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000014019a9e 9. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3980: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000014018e31 10. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:4304: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000014042fa7 11. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5605: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000014013749 12. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000140127f9 13. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000014011fce 14. /build/src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000001406ce8a 15. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000014973b42 16. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000001497268d 17. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000014974d24 18. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001492924b 19. /build/src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88641 20. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 21. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 22. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 23. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 24. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 25. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 26. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 27. ? @ 0x00007fbc6213eac3 28. ? @ 0x00007fbc621d0850 2025.07.28 12:03:17.843828 [ 17203 ] {} TCPHandler: Code: 43. DB::Exception: Illegal types Decimal(6, 4) and Decimal(6, 4) of arguments for aggregate function covarPop. (ILLEGAL_TYPE_OF_ARGUMENT), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String const&) @ 0x000000001011aceb 4. /build/src/AggregateFunctions/AggregateFunctionStatisticsSimple.h:266: std::shared_ptr DB::createAggregateFunctionStatisticsBinary(String const&, std::vector, std::allocator>> const&, DB::Array const&, DB::Settings const*) @ 0x0000000010c906fa 5. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000131e00dd 6. /build/src/AggregateFunctions/AggregateFunctionFactory.cpp:130: DB::AggregateFunctionFactory::get(String const&, DB::NullsAction, std::vector, std::allocator>> const&, DB::Array const&, DB::AggregateFunctionProperties&) const @ 0x00000000131df0ca 7. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3368: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000014032fed 8. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3838: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000014019a9e 9. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3980: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000014018e31 10. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:4304: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000014042fa7 11. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5605: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000014013749 12. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000140127f9 13. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000014011fce 14. /build/src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000001406ce8a 15. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000014973b42 16. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000001497268d 17. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000014974d24 18. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001492924b 19. /build/src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88641 20. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 21. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 22. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 23. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 24. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 25. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 26. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 27. ? @ 0x00007fbc6213eac3 28. ? @ 0x00007fbc621d0850 2025.07.28 12:03:17.994865 [ 17203 ] {1f280c1f-c14e-4e62-8d9b-7b181e86a484} executeQuery: Code: 43. DB::Exception: Illegal types Decimal(6, 4) and Decimal(6, 4) of arguments for aggregate function covarSamp. (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.6.10636.altinitytest (altinity build)) (from [::1]:51760) (comment: 00700_decimal_empty_aggregates.sql) (query 59, line 81) (in query: SELECT covarSamp(a, a), covarSamp(b, b), covarSamp(c, c) FROM decimal;), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String const&) @ 0x000000001011aceb 4. /build/src/AggregateFunctions/AggregateFunctionStatisticsSimple.h:266: std::shared_ptr DB::createAggregateFunctionStatisticsBinary(String const&, std::vector, std::allocator>> const&, DB::Array const&, DB::Settings const*) @ 0x0000000010c9045a 5. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000131e00dd 6. /build/src/AggregateFunctions/AggregateFunctionFactory.cpp:130: DB::AggregateFunctionFactory::get(String const&, DB::NullsAction, std::vector, std::allocator>> const&, DB::Array const&, DB::AggregateFunctionProperties&) const @ 0x00000000131df0ca 7. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3368: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000014032fed 8. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3838: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000014019a9e 9. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3980: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000014018e31 10. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:4304: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000014042fa7 11. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5605: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000014013749 12. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000140127f9 13. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000014011fce 14. /build/src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000001406ce8a 15. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000014973b42 16. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000001497268d 17. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000014974d24 18. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001492924b 19. /build/src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88641 20. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 21. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 22. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 23. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 24. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 25. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 26. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 27. ? @ 0x00007fbc6213eac3 28. ? @ 0x00007fbc621d0850 2025.07.28 12:03:18.000282 [ 17203 ] {} TCPHandler: Code: 43. DB::Exception: Illegal types Decimal(6, 4) and Decimal(6, 4) of arguments for aggregate function covarSamp. (ILLEGAL_TYPE_OF_ARGUMENT), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String const&) @ 0x000000001011aceb 4. /build/src/AggregateFunctions/AggregateFunctionStatisticsSimple.h:266: std::shared_ptr DB::createAggregateFunctionStatisticsBinary(String const&, std::vector, std::allocator>> const&, DB::Array const&, DB::Settings const*) @ 0x0000000010c9045a 5. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000131e00dd 6. /build/src/AggregateFunctions/AggregateFunctionFactory.cpp:130: DB::AggregateFunctionFactory::get(String const&, DB::NullsAction, std::vector, std::allocator>> const&, DB::Array const&, DB::AggregateFunctionProperties&) const @ 0x00000000131df0ca 7. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3368: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000014032fed 8. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3838: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000014019a9e 9. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3980: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000014018e31 10. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:4304: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000014042fa7 11. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5605: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000014013749 12. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000140127f9 13. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000014011fce 14. /build/src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000001406ce8a 15. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000014973b42 16. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000001497268d 17. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000014974d24 18. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001492924b 19. /build/src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88641 20. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 21. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 22. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 23. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 24. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 25. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 26. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 27. ? @ 0x00007fbc6213eac3 28. ? @ 0x00007fbc621d0850 2025.07.28 12:03:18.041871 [ 17203 ] {66eafb56-b6fe-410e-b620-b6a197ab5bc8} executeQuery: Code: 43. DB::Exception: Illegal types Decimal(6, 4) and Decimal(6, 4) of arguments for aggregate function corr. (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.6.10636.altinitytest (altinity build)) (from [::1]:51760) (comment: 00700_decimal_empty_aggregates.sql) (query 60, line 82) (in query: SELECT corr(a, a), corr(b, b), corr(c, c) FROM decimal;), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String const&) @ 0x000000001011aceb 4. /build/src/AggregateFunctions/AggregateFunctionStatisticsSimple.h:266: std::shared_ptr DB::createAggregateFunctionStatisticsBinary(String const&, std::vector, std::allocator>> const&, DB::Array const&, DB::Settings const*) @ 0x0000000010d49fea 5. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000131e00dd 6. /build/src/AggregateFunctions/AggregateFunctionFactory.cpp:130: DB::AggregateFunctionFactory::get(String const&, DB::NullsAction, std::vector, std::allocator>> const&, DB::Array const&, DB::AggregateFunctionProperties&) const @ 0x00000000131df0ca 7. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3368: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000014032fed 8. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3838: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000014019a9e 9. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3980: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000014018e31 10. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:4304: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000014042fa7 11. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5605: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000014013749 12. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000140127f9 13. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000014011fce 14. /build/src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000001406ce8a 15. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000014973b42 16. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000001497268d 17. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000014974d24 18. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001492924b 19. /build/src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88641 20. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 21. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 22. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 23. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 24. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 25. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 26. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 27. ? @ 0x00007fbc6213eac3 28. ? @ 0x00007fbc621d0850 2025.07.28 12:03:18.044884 [ 17203 ] {} TCPHandler: Code: 43. DB::Exception: Illegal types Decimal(6, 4) and Decimal(6, 4) of arguments for aggregate function corr. (ILLEGAL_TYPE_OF_ARGUMENT), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String const&) @ 0x000000001011aceb 4. /build/src/AggregateFunctions/AggregateFunctionStatisticsSimple.h:266: std::shared_ptr DB::createAggregateFunctionStatisticsBinary(String const&, std::vector, std::allocator>> const&, DB::Array const&, DB::Settings const*) @ 0x0000000010d49fea 5. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000131e00dd 6. /build/src/AggregateFunctions/AggregateFunctionFactory.cpp:130: DB::AggregateFunctionFactory::get(String const&, DB::NullsAction, std::vector, std::allocator>> const&, DB::Array const&, DB::AggregateFunctionProperties&) const @ 0x00000000131df0ca 7. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3368: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000014032fed 8. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3838: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000014019a9e 9. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3980: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000014018e31 10. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:4304: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000014042fa7 11. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5605: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000014013749 12. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000140127f9 13. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000014011fce 14. /build/src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000001406ce8a 15. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000014973b42 16. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000001497268d 17. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000014974d24 18. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001492924b 19. /build/src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88641 20. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 21. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 22. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 23. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 24. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 25. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 26. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 27. ? @ 0x00007fbc6213eac3 28. ? @ 0x00007fbc621d0850 2025.07.28 12:03:18.171731 [ 5112 ] {f3fdcfd7-620e-452a-8015-0a49ef6b4784} executeQuery: Code: 475. DB::Exception: Incompatible types of WITH FILL expression values with column type Date. (INVALID_WITH_FILL_EXPRESSION) (version 25.3.6.10636.altinitytest (altinity build)) (from [::1]:60952) (comment: 02561_with_fill_date_datetime_incompatible.sql) (query 1, line 1) (in query: SELECT today() AS a ORDER BY a ASC WITH FILL FROM now() - toIntervalMonth(1) TO now() + toIntervalDay(1) STEP 82600;), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x000000000a06b56b 4. /build/src/Processors/Transforms/FillingTransform.cpp:261: DB::FillingTransform::FillingTransform(DB::Block const&, DB::SortDescription const&, DB::SortDescription const&, std::shared_ptr, bool) @ 0x0000000016dbf7e7 5. /build/contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: std::shared_ptr std::__function::__policy_invoker (DB::Block const&, DB::Pipe::StreamType)>::__call_impl[abi:se190107] (DB::Block const&, DB::Pipe::StreamType)>>(std::__function::__policy_storage const*, DB::Block const&, DB::Pipe::StreamType) @ 0x0000000016dbb21f 6. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000013b9418e 7. /build/src/QueryPipeline/Pipe.cpp:632: DB::Pipe::addSimpleTransform(std::function (DB::Block const&, DB::Pipe::StreamType)> const&) @ 0x0000000013b93f5d 8. /build/src/Processors/QueryPlan/FillingStep.cpp:50: DB::FillingStep::transformPipeline(DB::QueryPipelineBuilder&, DB::BuildQueryPipelineSettings const&) @ 0x0000000016dba7c8 9. /build/src/Processors/QueryPlan/ITransformingStep.cpp:21: DB::ITransformingStep::updatePipeline(std::vector>, std::allocator>>>, DB::BuildQueryPipelineSettings const&) @ 0x0000000016dd1ba5 10. /build/src/Processors/QueryPlan/QueryPlan.cpp:201: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x0000000016e0076f 11. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:275: DB::InterpreterSelectQueryAnalyzer::buildQueryPipeline() @ 0x0000000014974614 12. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:242: DB::InterpreterSelectQueryAnalyzer::execute() @ 0x000000001497439e 13. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88dc9 14. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 15. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 16. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 17. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 18. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 19. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 20. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 21. ? @ 0x00007fbc6213eac3 22. ? @ 0x00007fbc621d0850 2025.07.28 12:03:18.180663 [ 5112 ] {} TCPHandler: Code: 475. DB::Exception: Incompatible types of WITH FILL expression values with column type Date. (INVALID_WITH_FILL_EXPRESSION), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x000000000a06b56b 4. /build/src/Processors/Transforms/FillingTransform.cpp:261: DB::FillingTransform::FillingTransform(DB::Block const&, DB::SortDescription const&, DB::SortDescription const&, std::shared_ptr, bool) @ 0x0000000016dbf7e7 5. /build/contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: std::shared_ptr std::__function::__policy_invoker (DB::Block const&, DB::Pipe::StreamType)>::__call_impl[abi:se190107] (DB::Block const&, DB::Pipe::StreamType)>>(std::__function::__policy_storage const*, DB::Block const&, DB::Pipe::StreamType) @ 0x0000000016dbb21f 6. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000013b9418e 7. /build/src/QueryPipeline/Pipe.cpp:632: DB::Pipe::addSimpleTransform(std::function (DB::Block const&, DB::Pipe::StreamType)> const&) @ 0x0000000013b93f5d 8. /build/src/Processors/QueryPlan/FillingStep.cpp:50: DB::FillingStep::transformPipeline(DB::QueryPipelineBuilder&, DB::BuildQueryPipelineSettings const&) @ 0x0000000016dba7c8 9. /build/src/Processors/QueryPlan/ITransformingStep.cpp:21: DB::ITransformingStep::updatePipeline(std::vector>, std::allocator>>>, DB::BuildQueryPipelineSettings const&) @ 0x0000000016dd1ba5 10. /build/src/Processors/QueryPlan/QueryPlan.cpp:201: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x0000000016e0076f 11. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:275: DB::InterpreterSelectQueryAnalyzer::buildQueryPipeline() @ 0x0000000014974614 12. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:242: DB::InterpreterSelectQueryAnalyzer::execute() @ 0x000000001497439e 13. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88dc9 14. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 15. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 16. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 17. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 18. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 19. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 20. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 21. ? @ 0x00007fbc6213eac3 22. ? @ 0x00007fbc621d0850 2025.07.28 12:03:18.473949 [ 3965 ] {} test_13.rmt2 (7f9b740d-015c-470e-8cc6-8ba33be0dc63): auto DB::StorageReplicatedMergeTree::processQueueEntry(ReplicatedMergeTreeQueue::SelectedEntryPtr)::(anonymous class)::operator()(LogEntryPtr &) const: Code: 86. DB::HTTPException: Received error from remote server http://146b4357c08d:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Ftest%2F01165%2Ftest_13%2Frmt%2Freplicas%2F1&part=20250728_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.6.10636.altinitytest (altinity build)) '. (RECEIVED_ERROR_FROM_REMOTE_IO_SERVER), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.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 const&, int&&, String const&, unsigned long&&, String const&) @ 0x000000000feda8d9 4. /build/src/IO/HTTPCommon.cpp:104: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x000000000feda6e2 5. /build/src/IO/HTTPCommon.cpp:93: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x000000000feda537 6. /build/src/IO/ReadWriteBufferFromHTTP.cpp:277: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x000000001184a4c4 7. /build/src/IO/ReadWriteBufferFromHTTP.cpp:285: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x000000001184a615 8. /build/src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x000000001184ae59 9. /build/src/IO/ReadWriteBufferFromHTTP.cpp:472: void std::__function::__policy_invoker::__call_impl[abi:se190107]>(std::__function::__policy_storage const*) @ 0x000000001184cedd 10. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001184858b 11. /build/src/IO/ReadWriteBufferFromHTTP.cpp:465: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x000000001184bf0b 12. /build/src/IO/ReadBuffer.h:60: DB::ReadBuffer::next() @ 0x000000000a148c7b 13. /build/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) @ 0x0000000011849fb2 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]>&)>&, 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&) @ 0x0000000011841980 15. /build/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) @ 0x000000001621208e 16. /build/src/Storages/StorageReplicatedMergeTree.cpp:5228: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl[abi:se190107] const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000015f9a5fe 17. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000015ed8bfd 18. /build/src/Storages/StorageReplicatedMergeTree.cpp:2514: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x0000000015ec9aab 19. /build/src/Storages/StorageReplicatedMergeTree.cpp:2349: DB::StorageReplicatedMergeTree::executeLogEntry(DB::ReplicatedMergeTreeLogEntry&) @ 0x0000000015eba91b 20. /build/src/Storages/StorageReplicatedMergeTree.cpp:3876: bool std::__function::__policy_invoker&)>::__call_impl[abi:se190107])::$_1, bool (std::shared_ptr&)>>(std::__function::__policy_storage const*, std::shared_ptr&) @ 0x0000000015f9837e 21. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000165d6fc3 22. /build/src/Storages/StorageReplicatedMergeTree.cpp:3872: DB::StorageReplicatedMergeTree::processQueueEntry(std::shared_ptr) @ 0x0000000015efc18a 23. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001624c1b2 24. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000162f9c70 25. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x00000000162fa55a 26. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc6653 27. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000000fccc4c3 28. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc3d92 29. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fcca080 30. ? @ 0x00007fbc6213eac3 31. ? @ 0x00007fbc621d0850 (version 25.3.6.10636.altinitytest (altinity build)) 2025.07.28 12:03:19.386965 [ 3960 ] {} test_13.rmt2 (7f9b740d-015c-470e-8cc6-8ba33be0dc63): auto DB::StorageReplicatedMergeTree::processQueueEntry(ReplicatedMergeTreeQueue::SelectedEntryPtr)::(anonymous class)::operator()(LogEntryPtr &) const: Code: 86. DB::HTTPException: Received error from remote server http://146b4357c08d:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Ftest%2F01165%2Ftest_13%2Frmt%2Freplicas%2F1&part=20250728_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.6.10636.altinitytest (altinity build)) '. (RECEIVED_ERROR_FROM_REMOTE_IO_SERVER), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.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 const&, int&&, String const&, unsigned long&&, String const&) @ 0x000000000feda8d9 4. /build/src/IO/HTTPCommon.cpp:104: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x000000000feda6e2 5. /build/src/IO/HTTPCommon.cpp:93: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x000000000feda537 6. /build/src/IO/ReadWriteBufferFromHTTP.cpp:277: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x000000001184a4c4 7. /build/src/IO/ReadWriteBufferFromHTTP.cpp:285: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x000000001184a615 8. /build/src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x000000001184ae59 9. /build/src/IO/ReadWriteBufferFromHTTP.cpp:472: void std::__function::__policy_invoker::__call_impl[abi:se190107]>(std::__function::__policy_storage const*) @ 0x000000001184cedd 10. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001184858b 11. /build/src/IO/ReadWriteBufferFromHTTP.cpp:465: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x000000001184bf0b 12. /build/src/IO/ReadBuffer.h:60: DB::ReadBuffer::next() @ 0x000000000a148c7b 13. /build/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) @ 0x0000000011849fb2 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]>&)>&, 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&) @ 0x0000000011841980 15. /build/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) @ 0x000000001621208e 16. /build/src/Storages/StorageReplicatedMergeTree.cpp:5228: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl[abi:se190107] const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000015f9a5fe 17. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000015ed8bfd 18. /build/src/Storages/StorageReplicatedMergeTree.cpp:2514: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x0000000015ec9aab 19. /build/src/Storages/StorageReplicatedMergeTree.cpp:2349: DB::StorageReplicatedMergeTree::executeLogEntry(DB::ReplicatedMergeTreeLogEntry&) @ 0x0000000015eba91b 20. /build/src/Storages/StorageReplicatedMergeTree.cpp:3876: bool std::__function::__policy_invoker&)>::__call_impl[abi:se190107])::$_1, bool (std::shared_ptr&)>>(std::__function::__policy_storage const*, std::shared_ptr&) @ 0x0000000015f9837e 21. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000165d6fc3 22. /build/src/Storages/StorageReplicatedMergeTree.cpp:3872: DB::StorageReplicatedMergeTree::processQueueEntry(std::shared_ptr) @ 0x0000000015efc18a 23. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001624c1b2 24. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000162f9c70 25. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x00000000162fa55a 26. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc6653 27. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000000fccc4c3 28. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc3d92 29. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fcca080 30. ? @ 0x00007fbc6213eac3 31. ? @ 0x00007fbc621d0850 (version 25.3.6.10636.altinitytest (altinity build)) 2025.07.28 12:03:19.916407 [ 3968 ] {} test_13.rmt2 (7f9b740d-015c-470e-8cc6-8ba33be0dc63): auto DB::StorageReplicatedMergeTree::processQueueEntry(ReplicatedMergeTreeQueue::SelectedEntryPtr)::(anonymous class)::operator()(LogEntryPtr &) const: Code: 86. DB::HTTPException: Received error from remote server http://146b4357c08d:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Ftest%2F01165%2Ftest_13%2Frmt%2Freplicas%2F1&part=20250728_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.6.10636.altinitytest (altinity build)) '. (RECEIVED_ERROR_FROM_REMOTE_IO_SERVER), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.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 const&, int&&, String const&, unsigned long&&, String const&) @ 0x000000000feda8d9 4. /build/src/IO/HTTPCommon.cpp:104: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x000000000feda6e2 5. /build/src/IO/HTTPCommon.cpp:93: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x000000000feda537 6. /build/src/IO/ReadWriteBufferFromHTTP.cpp:277: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x000000001184a4c4 7. /build/src/IO/ReadWriteBufferFromHTTP.cpp:285: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x000000001184a615 8. /build/src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x000000001184ae59 9. /build/src/IO/ReadWriteBufferFromHTTP.cpp:472: void std::__function::__policy_invoker::__call_impl[abi:se190107]>(std::__function::__policy_storage const*) @ 0x000000001184cedd 10. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001184858b 11. /build/src/IO/ReadWriteBufferFromHTTP.cpp:465: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x000000001184bf0b 12. /build/src/IO/ReadBuffer.h:60: DB::ReadBuffer::next() @ 0x000000000a148c7b 13. /build/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) @ 0x0000000011849fb2 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]>&)>&, 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&) @ 0x0000000011841980 15. /build/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) @ 0x000000001621208e 16. /build/src/Storages/StorageReplicatedMergeTree.cpp:5228: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl[abi:se190107] const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000015f9a5fe 17. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000015ed8bfd 18. /build/src/Storages/StorageReplicatedMergeTree.cpp:2514: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x0000000015ec9aab 19. /build/src/Storages/StorageReplicatedMergeTree.cpp:2349: DB::StorageReplicatedMergeTree::executeLogEntry(DB::ReplicatedMergeTreeLogEntry&) @ 0x0000000015eba91b 20. /build/src/Storages/StorageReplicatedMergeTree.cpp:3876: bool std::__function::__policy_invoker&)>::__call_impl[abi:se190107])::$_1, bool (std::shared_ptr&)>>(std::__function::__policy_storage const*, std::shared_ptr&) @ 0x0000000015f9837e 21. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000165d6fc3 22. /build/src/Storages/StorageReplicatedMergeTree.cpp:3872: DB::StorageReplicatedMergeTree::processQueueEntry(std::shared_ptr) @ 0x0000000015efc18a 23. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001624c1b2 24. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000162f9c70 25. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x00000000162fa55a 26. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc6653 27. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000000fccc4c3 28. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc3d92 29. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fcca080 30. ? @ 0x00007fbc6213eac3 31. ? @ 0x00007fbc621d0850 (version 25.3.6.10636.altinitytest (altinity build)) 2025.07.28 12:03:19.982567 [ 62075 ] {6fcdec38-e2bf-414f-913e-a0c8464ee21e} executeQuery: Code: 141. DB::Exception: Storage test_9.modify_sample_replicated doesn't support sampling. (SAMPLING_NOT_SUPPORTED) (version 25.3.6.10636.altinitytest (altinity build)) (from [::1]:60896) (comment: 01430_modify_sample_by_zookeeper_long.sql) (query 11, line 20) (in query: SELECT count(), min(x), max(x), sum(x), uniqExact(x) FROM modify_sample_replicated SAMPLE 0.1;), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x000000000a06b56b 4. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:920: DB::QueryAnalyzer::validateTableExpressionModifiers(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000014016fc9 5. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5383: DB::QueryAnalyzer::resolveQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&) @ 0x00000000140457dd 6. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5597: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000140136f0 7. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000140127f9 8. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000014011fce 9. /build/src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000001406ce8a 10. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000014973b42 11. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000001497268d 12. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000014974d24 13. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001492924b 14. /build/src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88641 15. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 16. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 17. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 18. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 19. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 20. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 21. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 22. ? @ 0x00007fbc6213eac3 23. ? @ 0x00007fbc621d0850 2025.07.28 12:03:19.984653 [ 62075 ] {} TCPHandler: Code: 141. DB::Exception: Storage test_9.modify_sample_replicated doesn't support sampling. (SAMPLING_NOT_SUPPORTED), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x000000000a06b56b 4. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:920: DB::QueryAnalyzer::validateTableExpressionModifiers(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000014016fc9 5. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5383: DB::QueryAnalyzer::resolveQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&) @ 0x00000000140457dd 6. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5597: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000140136f0 7. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000140127f9 8. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000014011fce 9. /build/src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000001406ce8a 10. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000014973b42 11. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000001497268d 12. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000014974d24 13. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001492924b 14. /build/src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88641 15. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 16. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 17. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 18. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 19. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 20. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 21. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 22. ? @ 0x00007fbc6213eac3 23. ? @ 0x00007fbc621d0850 2025.07.28 12:03:20.449334 [ 3964 ] {} test_13.rmt2 (7f9b740d-015c-470e-8cc6-8ba33be0dc63): auto DB::StorageReplicatedMergeTree::processQueueEntry(ReplicatedMergeTreeQueue::SelectedEntryPtr)::(anonymous class)::operator()(LogEntryPtr &) const: Code: 86. DB::HTTPException: Received error from remote server http://146b4357c08d:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Ftest%2F01165%2Ftest_13%2Frmt%2Freplicas%2F1&part=20250728_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.6.10636.altinitytest (altinity build)) '. (RECEIVED_ERROR_FROM_REMOTE_IO_SERVER), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.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 const&, int&&, String const&, unsigned long&&, String const&) @ 0x000000000feda8d9 4. /build/src/IO/HTTPCommon.cpp:104: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x000000000feda6e2 5. /build/src/IO/HTTPCommon.cpp:93: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x000000000feda537 6. /build/src/IO/ReadWriteBufferFromHTTP.cpp:277: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x000000001184a4c4 7. /build/src/IO/ReadWriteBufferFromHTTP.cpp:285: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x000000001184a615 8. /build/src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x000000001184ae59 9. /build/src/IO/ReadWriteBufferFromHTTP.cpp:472: void std::__function::__policy_invoker::__call_impl[abi:se190107]>(std::__function::__policy_storage const*) @ 0x000000001184cedd 10. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001184858b 11. /build/src/IO/ReadWriteBufferFromHTTP.cpp:465: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x000000001184bf0b 12. /build/src/IO/ReadBuffer.h:60: DB::ReadBuffer::next() @ 0x000000000a148c7b 13. /build/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) @ 0x0000000011849fb2 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]>&)>&, 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&) @ 0x0000000011841980 15. /build/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) @ 0x000000001621208e 16. /build/src/Storages/StorageReplicatedMergeTree.cpp:5228: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl[abi:se190107] const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000015f9a5fe 17. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000015ed8bfd 18. /build/src/Storages/StorageReplicatedMergeTree.cpp:2514: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x0000000015ec9aab 19. /build/src/Storages/StorageReplicatedMergeTree.cpp:2349: DB::StorageReplicatedMergeTree::executeLogEntry(DB::ReplicatedMergeTreeLogEntry&) @ 0x0000000015eba91b 20. /build/src/Storages/StorageReplicatedMergeTree.cpp:3876: bool std::__function::__policy_invoker&)>::__call_impl[abi:se190107])::$_1, bool (std::shared_ptr&)>>(std::__function::__policy_storage const*, std::shared_ptr&) @ 0x0000000015f9837e 21. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000165d6fc3 22. /build/src/Storages/StorageReplicatedMergeTree.cpp:3872: DB::StorageReplicatedMergeTree::processQueueEntry(std::shared_ptr) @ 0x0000000015efc18a 23. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001624c1b2 24. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000162f9c70 25. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x00000000162fa55a 26. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc6653 27. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000000fccc4c3 28. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc3d92 29. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fcca080 30. ? @ 0x00007fbc6213eac3 31. ? @ 0x00007fbc621d0850 (version 25.3.6.10636.altinitytest (altinity build)) 2025.07.28 12:03:21.021231 [ 3968 ] {} test_13.rmt2 (7f9b740d-015c-470e-8cc6-8ba33be0dc63): auto DB::StorageReplicatedMergeTree::processQueueEntry(ReplicatedMergeTreeQueue::SelectedEntryPtr)::(anonymous class)::operator()(LogEntryPtr &) const: Code: 86. DB::HTTPException: Received error from remote server http://146b4357c08d:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Ftest%2F01165%2Ftest_13%2Frmt%2Freplicas%2F1&part=20250728_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.6.10636.altinitytest (altinity build)) '. (RECEIVED_ERROR_FROM_REMOTE_IO_SERVER), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.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 const&, int&&, String const&, unsigned long&&, String const&) @ 0x000000000feda8d9 4. /build/src/IO/HTTPCommon.cpp:104: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x000000000feda6e2 5. /build/src/IO/HTTPCommon.cpp:93: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x000000000feda537 6. /build/src/IO/ReadWriteBufferFromHTTP.cpp:277: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x000000001184a4c4 7. /build/src/IO/ReadWriteBufferFromHTTP.cpp:285: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x000000001184a615 8. /build/src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x000000001184ae59 9. /build/src/IO/ReadWriteBufferFromHTTP.cpp:472: void std::__function::__policy_invoker::__call_impl[abi:se190107]>(std::__function::__policy_storage const*) @ 0x000000001184cedd 10. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001184858b 11. /build/src/IO/ReadWriteBufferFromHTTP.cpp:465: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x000000001184bf0b 12. /build/src/IO/ReadBuffer.h:60: DB::ReadBuffer::next() @ 0x000000000a148c7b 13. /build/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) @ 0x0000000011849fb2 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]>&)>&, 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&) @ 0x0000000011841980 15. /build/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) @ 0x000000001621208e 16. /build/src/Storages/StorageReplicatedMergeTree.cpp:5228: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl[abi:se190107] const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000015f9a5fe 17. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000015ed8bfd 18. /build/src/Storages/StorageReplicatedMergeTree.cpp:2514: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x0000000015ec9aab 19. /build/src/Storages/StorageReplicatedMergeTree.cpp:2349: DB::StorageReplicatedMergeTree::executeLogEntry(DB::ReplicatedMergeTreeLogEntry&) @ 0x0000000015eba91b 20. /build/src/Storages/StorageReplicatedMergeTree.cpp:3876: bool std::__function::__policy_invoker&)>::__call_impl[abi:se190107])::$_1, bool (std::shared_ptr&)>>(std::__function::__policy_storage const*, std::shared_ptr&) @ 0x0000000015f9837e 21. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000165d6fc3 22. /build/src/Storages/StorageReplicatedMergeTree.cpp:3872: DB::StorageReplicatedMergeTree::processQueueEntry(std::shared_ptr) @ 0x0000000015efc18a 23. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001624c1b2 24. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000162f9c70 25. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x00000000162fa55a 26. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc6653 27. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000000fccc4c3 28. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc3d92 29. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fcca080 30. ? @ 0x00007fbc6213eac3 31. ? @ 0x00007fbc621d0850 (version 25.3.6.10636.altinitytest (altinity build)) 2025.07.28 12:03:21.432962 [ 3976 ] {} test_13.rmt2 (7f9b740d-015c-470e-8cc6-8ba33be0dc63): auto DB::StorageReplicatedMergeTree::processQueueEntry(ReplicatedMergeTreeQueue::SelectedEntryPtr)::(anonymous class)::operator()(LogEntryPtr &) const: Code: 86. DB::HTTPException: Received error from remote server http://146b4357c08d:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Ftest%2F01165%2Ftest_13%2Frmt%2Freplicas%2F1&part=20250728_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.6.10636.altinitytest (altinity build)) '. (RECEIVED_ERROR_FROM_REMOTE_IO_SERVER), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.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 const&, int&&, String const&, unsigned long&&, String const&) @ 0x000000000feda8d9 4. /build/src/IO/HTTPCommon.cpp:104: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x000000000feda6e2 5. /build/src/IO/HTTPCommon.cpp:93: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x000000000feda537 6. /build/src/IO/ReadWriteBufferFromHTTP.cpp:277: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x000000001184a4c4 7. /build/src/IO/ReadWriteBufferFromHTTP.cpp:285: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x000000001184a615 8. /build/src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x000000001184ae59 9. /build/src/IO/ReadWriteBufferFromHTTP.cpp:472: void std::__function::__policy_invoker::__call_impl[abi:se190107]>(std::__function::__policy_storage const*) @ 0x000000001184cedd 10. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001184858b 11. /build/src/IO/ReadWriteBufferFromHTTP.cpp:465: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x000000001184bf0b 12. /build/src/IO/ReadBuffer.h:60: DB::ReadBuffer::next() @ 0x000000000a148c7b 13. /build/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) @ 0x0000000011849fb2 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]>&)>&, 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&) @ 0x0000000011841980 15. /build/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) @ 0x000000001621208e 16. /build/src/Storages/StorageReplicatedMergeTree.cpp:5228: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl[abi:se190107] const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000015f9a5fe 17. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000015ed8bfd 18. /build/src/Storages/StorageReplicatedMergeTree.cpp:2514: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x0000000015ec9aab 19. /build/src/Storages/StorageReplicatedMergeTree.cpp:2349: DB::StorageReplicatedMergeTree::executeLogEntry(DB::ReplicatedMergeTreeLogEntry&) @ 0x0000000015eba91b 20. /build/src/Storages/StorageReplicatedMergeTree.cpp:3876: bool std::__function::__policy_invoker&)>::__call_impl[abi:se190107])::$_1, bool (std::shared_ptr&)>>(std::__function::__policy_storage const*, std::shared_ptr&) @ 0x0000000015f9837e 21. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000165d6fc3 22. /build/src/Storages/StorageReplicatedMergeTree.cpp:3872: DB::StorageReplicatedMergeTree::processQueueEntry(std::shared_ptr) @ 0x0000000015efc18a 23. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001624c1b2 24. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000162f9c70 25. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x00000000162fa55a 26. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc6653 27. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000000fccc4c3 28. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc3d92 29. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fcca080 30. ? @ 0x00007fbc6213eac3 31. ? @ 0x00007fbc621d0850 (version 25.3.6.10636.altinitytest (altinity build)) 2025.07.28 12:03:21.645330 [ 3971 ] {} test_13.rmt2 (7f9b740d-015c-470e-8cc6-8ba33be0dc63): auto DB::StorageReplicatedMergeTree::processQueueEntry(ReplicatedMergeTreeQueue::SelectedEntryPtr)::(anonymous class)::operator()(LogEntryPtr &) const: Code: 86. DB::HTTPException: Received error from remote server http://146b4357c08d:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Ftest%2F01165%2Ftest_13%2Frmt%2Freplicas%2F1&part=20250728_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.6.10636.altinitytest (altinity build)) '. (RECEIVED_ERROR_FROM_REMOTE_IO_SERVER), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.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 const&, int&&, String const&, unsigned long&&, String const&) @ 0x000000000feda8d9 4. /build/src/IO/HTTPCommon.cpp:104: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x000000000feda6e2 5. /build/src/IO/HTTPCommon.cpp:93: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x000000000feda537 6. /build/src/IO/ReadWriteBufferFromHTTP.cpp:277: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x000000001184a4c4 7. /build/src/IO/ReadWriteBufferFromHTTP.cpp:285: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x000000001184a615 8. /build/src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x000000001184ae59 9. /build/src/IO/ReadWriteBufferFromHTTP.cpp:472: void std::__function::__policy_invoker::__call_impl[abi:se190107]>(std::__function::__policy_storage const*) @ 0x000000001184cedd 10. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001184858b 11. /build/src/IO/ReadWriteBufferFromHTTP.cpp:465: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x000000001184bf0b 12. /build/src/IO/ReadBuffer.h:60: DB::ReadBuffer::next() @ 0x000000000a148c7b 13. /build/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) @ 0x0000000011849fb2 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]>&)>&, 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&) @ 0x0000000011841980 15. /build/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) @ 0x000000001621208e 16. /build/src/Storages/StorageReplicatedMergeTree.cpp:5228: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl[abi:se190107] const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000015f9a5fe 17. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000015ed8bfd 18. /build/src/Storages/StorageReplicatedMergeTree.cpp:2514: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x0000000015ec9aab 19. /build/src/Storages/StorageReplicatedMergeTree.cpp:2349: DB::StorageReplicatedMergeTree::executeLogEntry(DB::ReplicatedMergeTreeLogEntry&) @ 0x0000000015eba91b 20. /build/src/Storages/StorageReplicatedMergeTree.cpp:3876: bool std::__function::__policy_invoker&)>::__call_impl[abi:se190107])::$_1, bool (std::shared_ptr&)>>(std::__function::__policy_storage const*, std::shared_ptr&) @ 0x0000000015f9837e 21. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000165d6fc3 22. /build/src/Storages/StorageReplicatedMergeTree.cpp:3872: DB::StorageReplicatedMergeTree::processQueueEntry(std::shared_ptr) @ 0x0000000015efc18a 23. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001624c1b2 24. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000162f9c70 25. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x00000000162fa55a 26. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc6653 27. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000000fccc4c3 28. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc3d92 29. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fcca080 30. ? @ 0x00007fbc6213eac3 31. ? @ 0x00007fbc621d0850 (version 25.3.6.10636.altinitytest (altinity build)) 2025.07.28 12:03:21.647768 [ 17255 ] {1a6a915c-1afc-425d-bdce-c36c6758e267} executeQuery: Code: 41. DB::Exception: Cannot parse DateTime: Cannot parse DateTime64(3, 'UTC') from String: In scope SELECT toDateTime64('1234', 3, 'UTC'). (CANNOT_PARSE_DATETIME) (version 25.3.6.10636.altinitytest (altinity build)) (from [::1]:32820) (comment: 02889_datetime64_from_string.sql) (query 6, line 8) (in query: SELECT toDateTime64('1234', 3, 'UTC');), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000000a074fcb 4. /build/src/IO/ReadHelpers.cpp:1597: void DB::readDateTimeTextFallback(long&, DB::ReadBuffer&, DateLUTImpl const&, char const*, char const*) @ 0x000000000fc7c700 5. /build/src/IO/ReadHelpers.h:1131: void DB::readDateTimeTextImpl(DB::DateTime64&, unsigned int, DB::ReadBuffer&, DateLUTImpl const&, char const*, char const*) @ 0x000000000e8242fe 6. /build/src/IO/ReadHelpers.h:1221: COW::immutable_ptr DB::detail::ConvertThroughParsing::execute(std::vector> const&, std::shared_ptr const&, unsigned long, unsigned int) @ 0x00000000130c3736 7. /build/src/Functions/FunctionsConversion.h:1580: COW::immutable_ptr DB::detail::ConvertImpl::execute(std::vector> const&, std::shared_ptr const&, unsigned long, DB::detail::BehaviourOnErrorFromString, unsigned int) @ 0x00000000130c335e 8. /build/src/Functions/FunctionsConversion.h:2409: 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 @ 0x00000000130b8144 9. /build/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&&) @ 0x0000000012fa9821 10. /build/src/Functions/FunctionsConversion.h:2487: DB::detail::FunctionConvert::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000012fc645b 11. /build/src/Functions/FunctionsConversion.h:2307: DB::detail::FunctionConvert::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000012fc5c9a 12. /build/src/Functions/IFunction.h:437: DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000a069f2a 13. /build/src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000012d9965a 14. /build/src/Functions/IFunction.cpp:351: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d93b02 15. /build/src/Functions/IFunction.cpp:177: DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d93698 16. /build/src/Functions/IFunction.cpp:343: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d93aad 17. /build/src/Functions/IFunction.cpp:420: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d95059 18. /build/src/Functions/IFunction.cpp:498: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d95c72 19. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3567: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000014034494 20. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3838: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000014019a9e 21. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3980: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000014018e31 22. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:4304: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000014042fa7 23. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5605: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000014013749 24. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000140127f9 25. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000014011fce 26. /build/src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000001406ce8a 27. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000014973b42 28. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000001497268d 29. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000014974d24 30. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001492924b 31. /build/src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88641 2025.07.28 12:03:21.651231 [ 17255 ] {} TCPHandler: Code: 41. DB::Exception: Cannot parse DateTime: Cannot parse DateTime64(3, 'UTC') from String: In scope SELECT toDateTime64('1234', 3, 'UTC'). (CANNOT_PARSE_DATETIME), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000000a074fcb 4. /build/src/IO/ReadHelpers.cpp:1597: void DB::readDateTimeTextFallback(long&, DB::ReadBuffer&, DateLUTImpl const&, char const*, char const*) @ 0x000000000fc7c700 5. /build/src/IO/ReadHelpers.h:1131: void DB::readDateTimeTextImpl(DB::DateTime64&, unsigned int, DB::ReadBuffer&, DateLUTImpl const&, char const*, char const*) @ 0x000000000e8242fe 6. /build/src/IO/ReadHelpers.h:1221: COW::immutable_ptr DB::detail::ConvertThroughParsing::execute(std::vector> const&, std::shared_ptr const&, unsigned long, unsigned int) @ 0x00000000130c3736 7. /build/src/Functions/FunctionsConversion.h:1580: COW::immutable_ptr DB::detail::ConvertImpl::execute(std::vector> const&, std::shared_ptr const&, unsigned long, DB::detail::BehaviourOnErrorFromString, unsigned int) @ 0x00000000130c335e 8. /build/src/Functions/FunctionsConversion.h:2409: 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 @ 0x00000000130b8144 9. /build/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&&) @ 0x0000000012fa9821 10. /build/src/Functions/FunctionsConversion.h:2487: DB::detail::FunctionConvert::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000012fc645b 11. /build/src/Functions/FunctionsConversion.h:2307: DB::detail::FunctionConvert::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000012fc5c9a 12. /build/src/Functions/IFunction.h:437: DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000a069f2a 13. /build/src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000012d9965a 14. /build/src/Functions/IFunction.cpp:351: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d93b02 15. /build/src/Functions/IFunction.cpp:177: DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d93698 16. /build/src/Functions/IFunction.cpp:343: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d93aad 17. /build/src/Functions/IFunction.cpp:420: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d95059 18. /build/src/Functions/IFunction.cpp:498: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d95c72 19. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3567: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000014034494 20. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3838: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000014019a9e 21. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3980: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000014018e31 22. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:4304: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000014042fa7 23. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5605: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000014013749 24. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000140127f9 25. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000014011fce 26. /build/src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000001406ce8a 27. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000014973b42 28. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000001497268d 29. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000014974d24 30. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001492924b 31. /build/src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88641 2025.07.28 12:03:21.672266 [ 17255 ] {83991d98-af86-4d29-b482-2f4978797950} executeQuery: Code: 41. DB::Exception: Cannot parse DateTime: Cannot parse DateTime64(3, 'UTC') from String: In scope SELECT toDateTime64('0', 3, 'UTC'). (CANNOT_PARSE_DATETIME) (version 25.3.6.10636.altinitytest (altinity build)) (from [::1]:32820) (comment: 02889_datetime64_from_string.sql) (query 7, line 9) (in query: SELECT toDateTime64('0', 3, 'UTC');), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000000a074fcb 4. /build/src/IO/ReadHelpers.cpp:1597: void DB::readDateTimeTextFallback(long&, DB::ReadBuffer&, DateLUTImpl const&, char const*, char const*) @ 0x000000000fc7c700 5. /build/src/IO/ReadHelpers.h:1131: void DB::readDateTimeTextImpl(DB::DateTime64&, unsigned int, DB::ReadBuffer&, DateLUTImpl const&, char const*, char const*) @ 0x000000000e8242fe 6. /build/src/IO/ReadHelpers.h:1221: COW::immutable_ptr DB::detail::ConvertThroughParsing::execute(std::vector> const&, std::shared_ptr const&, unsigned long, unsigned int) @ 0x00000000130c3736 7. /build/src/Functions/FunctionsConversion.h:1580: COW::immutable_ptr DB::detail::ConvertImpl::execute(std::vector> const&, std::shared_ptr const&, unsigned long, DB::detail::BehaviourOnErrorFromString, unsigned int) @ 0x00000000130c335e 8. /build/src/Functions/FunctionsConversion.h:2409: 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 @ 0x00000000130b8144 9. /build/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&&) @ 0x0000000012fa9821 10. /build/src/Functions/FunctionsConversion.h:2487: DB::detail::FunctionConvert::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000012fc645b 11. /build/src/Functions/FunctionsConversion.h:2307: DB::detail::FunctionConvert::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000012fc5c9a 12. /build/src/Functions/IFunction.h:437: DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000a069f2a 13. /build/src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000012d9965a 14. /build/src/Functions/IFunction.cpp:351: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d93b02 15. /build/src/Functions/IFunction.cpp:177: DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d93698 16. /build/src/Functions/IFunction.cpp:343: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d93aad 17. /build/src/Functions/IFunction.cpp:420: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d95059 18. /build/src/Functions/IFunction.cpp:498: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d95c72 19. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3567: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000014034494 20. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3838: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000014019a9e 21. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3980: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000014018e31 22. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:4304: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000014042fa7 23. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5605: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000014013749 24. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000140127f9 25. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000014011fce 26. /build/src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000001406ce8a 27. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000014973b42 28. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000001497268d 29. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000014974d24 30. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001492924b 31. /build/src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88641 2025.07.28 12:03:21.675875 [ 17255 ] {} TCPHandler: Code: 41. DB::Exception: Cannot parse DateTime: Cannot parse DateTime64(3, 'UTC') from String: In scope SELECT toDateTime64('0', 3, 'UTC'). (CANNOT_PARSE_DATETIME), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000000a074fcb 4. /build/src/IO/ReadHelpers.cpp:1597: void DB::readDateTimeTextFallback(long&, DB::ReadBuffer&, DateLUTImpl const&, char const*, char const*) @ 0x000000000fc7c700 5. /build/src/IO/ReadHelpers.h:1131: void DB::readDateTimeTextImpl(DB::DateTime64&, unsigned int, DB::ReadBuffer&, DateLUTImpl const&, char const*, char const*) @ 0x000000000e8242fe 6. /build/src/IO/ReadHelpers.h:1221: COW::immutable_ptr DB::detail::ConvertThroughParsing::execute(std::vector> const&, std::shared_ptr const&, unsigned long, unsigned int) @ 0x00000000130c3736 7. /build/src/Functions/FunctionsConversion.h:1580: COW::immutable_ptr DB::detail::ConvertImpl::execute(std::vector> const&, std::shared_ptr const&, unsigned long, DB::detail::BehaviourOnErrorFromString, unsigned int) @ 0x00000000130c335e 8. /build/src/Functions/FunctionsConversion.h:2409: 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 @ 0x00000000130b8144 9. /build/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&&) @ 0x0000000012fa9821 10. /build/src/Functions/FunctionsConversion.h:2487: DB::detail::FunctionConvert::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000012fc645b 11. /build/src/Functions/FunctionsConversion.h:2307: DB::detail::FunctionConvert::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000012fc5c9a 12. /build/src/Functions/IFunction.h:437: DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000a069f2a 13. /build/src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000012d9965a 14. /build/src/Functions/IFunction.cpp:351: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d93b02 15. /build/src/Functions/IFunction.cpp:177: DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d93698 16. /build/src/Functions/IFunction.cpp:343: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d93aad 17. /build/src/Functions/IFunction.cpp:420: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d95059 18. /build/src/Functions/IFunction.cpp:498: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d95c72 19. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3567: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000014034494 20. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3838: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000014019a9e 21. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3980: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000014018e31 22. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:4304: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000014042fa7 23. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5605: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000014013749 24. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000140127f9 25. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000014011fce 26. /build/src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000001406ce8a 27. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000014973b42 28. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000001497268d 29. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000014974d24 30. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001492924b 31. /build/src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88641 2025.07.28 12:03:21.848636 [ 17255 ] {f19c4ee7-65be-4a12-b70f-8025467dcdca} executeQuery: Code: 41. DB::Exception: Cannot parse DateTime: In scope SELECT CAST('0', 'DateTime64(3, \'UTC\')'). (CANNOT_PARSE_DATETIME) (version 25.3.6.10636.altinitytest (altinity build)) (from [::1]:32820) (comment: 02889_datetime64_from_string.sql) (query 8, line 10) (in query: SELECT cast('0' as DateTime64(3, 'UTC'));), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000000a074fcb 4. /build/src/IO/ReadHelpers.cpp:1597: void DB::readDateTimeTextFallback(long&, DB::ReadBuffer&, DateLUTImpl const&, char const*, char const*) @ 0x000000000fc7c700 5. /build/src/IO/ReadHelpers.h:1131: void DB::readDateTimeTextImpl(DB::DateTime64&, unsigned int, DB::ReadBuffer&, DateLUTImpl const&, char const*, char const*) @ 0x000000000e8242fe 6. /build/src/IO/ReadHelpers.h:1221: COW::immutable_ptr DB::detail::ConvertThroughParsing::execute(std::vector> const&, std::shared_ptr const&, unsigned long, unsigned int) @ 0x0000000012f70b16 7. /build/src/Functions/FunctionsConversion.h:1580: 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 @ 0x0000000012f6a944 8. /build/src/Core/callOnTypeIndex.h:280: 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 @ 0x0000000012f69938 9. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: COW::immutable_ptr std::__function::__policy_invoker::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)>::__call_impl[abi:se190107]::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) @ 0x0000000012f6956c 10. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000012ddcb1b 11. /build/src/Functions/IFunction.h:57: DB::IExecutableFunction::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000a08134a 12. /build/src/Functions/IFunction.cpp:351: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d93b02 13. /build/src/Functions/IFunction.cpp:177: DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d93698 14. /build/src/Functions/IFunction.cpp:343: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d93aad 15. /build/src/Functions/IFunction.cpp:424: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d94e1b 16. /build/src/Functions/IFunction.cpp:498: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d95c72 17. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3567: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000014034494 18. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3838: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000014019a9e 19. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3980: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000014018e31 20. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:4304: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000014042fa7 21. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5605: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000014013749 22. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000140127f9 23. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000014011fce 24. /build/src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000001406ce8a 25. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000014973b42 26. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000001497268d 27. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000014974d24 28. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001492924b 29. /build/src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88641 30. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 31. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 2025.07.28 12:03:21.855846 [ 17255 ] {} TCPHandler: Code: 41. DB::Exception: Cannot parse DateTime: In scope SELECT CAST('0', 'DateTime64(3, \'UTC\')'). (CANNOT_PARSE_DATETIME), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000000a074fcb 4. /build/src/IO/ReadHelpers.cpp:1597: void DB::readDateTimeTextFallback(long&, DB::ReadBuffer&, DateLUTImpl const&, char const*, char const*) @ 0x000000000fc7c700 5. /build/src/IO/ReadHelpers.h:1131: void DB::readDateTimeTextImpl(DB::DateTime64&, unsigned int, DB::ReadBuffer&, DateLUTImpl const&, char const*, char const*) @ 0x000000000e8242fe 6. /build/src/IO/ReadHelpers.h:1221: COW::immutable_ptr DB::detail::ConvertThroughParsing::execute(std::vector> const&, std::shared_ptr const&, unsigned long, unsigned int) @ 0x0000000012f70b16 7. /build/src/Functions/FunctionsConversion.h:1580: 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 @ 0x0000000012f6a944 8. /build/src/Core/callOnTypeIndex.h:280: 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 @ 0x0000000012f69938 9. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: COW::immutable_ptr std::__function::__policy_invoker::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)>::__call_impl[abi:se190107]::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) @ 0x0000000012f6956c 10. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000012ddcb1b 11. /build/src/Functions/IFunction.h:57: DB::IExecutableFunction::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000a08134a 12. /build/src/Functions/IFunction.cpp:351: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d93b02 13. /build/src/Functions/IFunction.cpp:177: DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d93698 14. /build/src/Functions/IFunction.cpp:343: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d93aad 15. /build/src/Functions/IFunction.cpp:424: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d94e1b 16. /build/src/Functions/IFunction.cpp:498: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d95c72 17. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3567: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000014034494 18. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3838: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000014019a9e 19. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3980: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000014018e31 20. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:4304: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000014042fa7 21. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5605: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000014013749 22. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000140127f9 23. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000014011fce 24. /build/src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000001406ce8a 25. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000014973b42 26. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000001497268d 27. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000014974d24 28. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001492924b 29. /build/src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88641 30. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 31. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 2025.07.28 12:03:22.360304 [ 62075 ] {30936fc9-7aea-4006-a598-10caf41da99d} executeQuery: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=19, jobs=0): While reading or decompressing /var/lib/clickhouse/store/b05/b05fe8f5-3668-4492-9f3a-59f7df2bbacb/20000101_0_10_1/data.cmrk3 (position: 0, typename: DB::AsynchronousReadBufferFromFileWithDescriptorsCache, compressed data header: ): (while reading from part /var/lib/clickhouse/store/b05/b05fe8f5-3668-4492-9f3a-59f7df2bbacb/20000101_0_10_1/ in table test_9.modify_sample_replicated (b05fe8f5-3668-4492-9f3a-59f7df2bbacb) located on disk default of type local, from mark 0 with max_rows_to_read = 110): While executing MergeTreeSelect(pool: ReadPoolParallelReplicas, algorithm: Thread). (CANNOT_SCHEDULE_TASK) (version 25.3.6.10636.altinitytest (altinity build)) (from [::1]:60896) (comment: 01430_modify_sample_by_zookeeper_long.sql) (query 16, line 28) (in query: SELECT count(), min(x), max(x), sum(x), uniqExact(x) FROM modify_sample_replicated SAMPLE 0.1;), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000fccaeeb 4. /build/src/Common/ThreadPool.cpp:275: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000fccc813 5. /build/src/Common/ThreadPool.cpp:323: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fcc7bbc 6. /build/src/Common/ThreadPool.cpp:494: ThreadPoolImpl>::scheduleOrThrowOnError(std::function, Priority) @ 0x000000000fcc7a0e 7. /build/src/Common/threadPoolCallbackRunner.h:52: std::function (std::function&&, Priority)> DB::threadPoolCallbackRunnerUnsafe>(ThreadPoolImpl>&, String const&)::'lambda'(std::function&&, Priority)::operator()(std::function&&, Priority) @ 0x000000001320131a 8. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: std::future std::__function::__policy_invoker (std::function&&, Priority)>::__call_impl[abi:se190107] (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&&) @ 0x000000001320110f 9. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000132002ce 10. /build/src/IO/AsynchronousReadBufferFromFileDescriptor.cpp:62: DB::AsynchronousReadBufferFromFileDescriptor::asyncReadInto(char*, unsigned long, Priority) @ 0x00000000131f77d0 11. /build/src/IO/AsynchronousReadBufferFromFileDescriptor.cpp:100: DB::AsynchronousReadBufferFromFileDescriptor::nextImpl() @ 0x00000000131f7acb 12. /build/src/IO/ReadBuffer.h:60: DB::ReadBuffer::next() @ 0x000000000a148c7b 13. /build/src/IO/ReadBuffer.h:96: DB::CompressedReadBufferBase::readCompressedData(unsigned long&, unsigned long&, bool) @ 0x0000000017935e2b 14. /build/src/Compression/CompressedReadBufferFromFile.cpp:25: DB::CompressedReadBufferFromFile::nextImpl() @ 0x0000000017937a5d 15. /build/src/IO/ReadBuffer.h:60: DB::ReadBuffer::next() @ 0x000000000a148c7b 16. /build/src/IO/ReadBuffer.h:96: DB::MergeTreeMarksLoader::loadMarksImpl() @ 0x00000000164731f2 17. /build/src/Storages/MergeTree/MergeTreeMarksLoader.cpp:232: DB::MergeTreeMarksLoader::loadMarksSync() @ 0x000000001647232a 18. /build/src/Storages/MergeTree/MergeTreeMarksLoader.cpp:268: std::__packaged_task_func> (DB::MergeTreeMarksLoader::loadMarksAsync()::$_0&&, Priority)> DB::threadPoolCallbackRunnerUnsafe, DB::MergeTreeMarksLoader::loadMarksAsync()::$_0>(ThreadPoolImpl>&, String const&)::'lambda'(DB::MergeTreeMarksLoader::loadMarksAsync()::$_0&&, Priority)::operator()(DB::MergeTreeMarksLoader::loadMarksAsync()::$_0&&, Priority)::'lambda'(), std::allocator> (DB::MergeTreeMarksLoader::loadMarksAsync()::$_0&&, Priority)> DB::threadPoolCallbackRunnerUnsafe, DB::MergeTreeMarksLoader::loadMarksAsync()::$_0>(ThreadPoolImpl>&, String const&)::'lambda'(DB::MergeTreeMarksLoader::loadMarksAsync()::$_0&&, Priority)::operator()(DB::MergeTreeMarksLoader::loadMarksAsync()::$_0&&, Priority)::'lambda'()>, std::shared_ptr ()>::operator()() @ 0x0000000016474b84 19. /build/contrib/llvm-project/libcxx/include/future:1589: std::packaged_task ()>::operator()() @ 0x000000001647685f 20. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc6653 21. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000000fccc4c3 22. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc3d92 23. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fcca080 24. ? @ 0x00007fbc6213eac3 25. ? @ 0x00007fbc621d0850 2025.07.28 12:03:22.409482 [ 3972 ] {} test_13.rmt2 (7f9b740d-015c-470e-8cc6-8ba33be0dc63): auto DB::StorageReplicatedMergeTree::processQueueEntry(ReplicatedMergeTreeQueue::SelectedEntryPtr)::(anonymous class)::operator()(LogEntryPtr &) const: Code: 86. DB::HTTPException: Received error from remote server http://146b4357c08d:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Ftest%2F01165%2Ftest_13%2Frmt%2Freplicas%2F1&part=20250728_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.6.10636.altinitytest (altinity build)) '. (RECEIVED_ERROR_FROM_REMOTE_IO_SERVER), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.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 const&, int&&, String const&, unsigned long&&, String const&) @ 0x000000000feda8d9 4. /build/src/IO/HTTPCommon.cpp:104: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x000000000feda6e2 5. /build/src/IO/HTTPCommon.cpp:93: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x000000000feda537 6. /build/src/IO/ReadWriteBufferFromHTTP.cpp:277: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x000000001184a4c4 7. /build/src/IO/ReadWriteBufferFromHTTP.cpp:285: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x000000001184a615 8. /build/src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x000000001184ae59 9. /build/src/IO/ReadWriteBufferFromHTTP.cpp:472: void std::__function::__policy_invoker::__call_impl[abi:se190107]>(std::__function::__policy_storage const*) @ 0x000000001184cedd 10. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001184858b 11. /build/src/IO/ReadWriteBufferFromHTTP.cpp:465: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x000000001184bf0b 12. /build/src/IO/ReadBuffer.h:60: DB::ReadBuffer::next() @ 0x000000000a148c7b 13. /build/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) @ 0x0000000011849fb2 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]>&)>&, 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&) @ 0x0000000011841980 15. /build/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) @ 0x000000001621208e 16. /build/src/Storages/StorageReplicatedMergeTree.cpp:5228: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl[abi:se190107] const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000015f9a5fe 17. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000015ed8bfd 18. /build/src/Storages/StorageReplicatedMergeTree.cpp:2514: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x0000000015ec9aab 19. /build/src/Storages/StorageReplicatedMergeTree.cpp:2349: DB::StorageReplicatedMergeTree::executeLogEntry(DB::ReplicatedMergeTreeLogEntry&) @ 0x0000000015eba91b 20. /build/src/Storages/StorageReplicatedMergeTree.cpp:3876: bool std::__function::__policy_invoker&)>::__call_impl[abi:se190107])::$_1, bool (std::shared_ptr&)>>(std::__function::__policy_storage const*, std::shared_ptr&) @ 0x0000000015f9837e 21. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000165d6fc3 22. /build/src/Storages/StorageReplicatedMergeTree.cpp:3872: DB::StorageReplicatedMergeTree::processQueueEntry(std::shared_ptr) @ 0x0000000015efc18a 23. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001624c1b2 24. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000162f9c70 25. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x00000000162fa55a 26. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc6653 27. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000000fccc4c3 28. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc3d92 29. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fcca080 30. ? @ 0x00007fbc6213eac3 31. ? @ 0x00007fbc621d0850 (version 25.3.6.10636.altinitytest (altinity build)) 2025.07.28 12:03:22.457856 [ 62075 ] {} TCPHandler: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=19, jobs=0): While reading or decompressing /var/lib/clickhouse/store/b05/b05fe8f5-3668-4492-9f3a-59f7df2bbacb/20000101_0_10_1/data.cmrk3 (position: 0, typename: DB::AsynchronousReadBufferFromFileWithDescriptorsCache, compressed data header: ): (while reading from part /var/lib/clickhouse/store/b05/b05fe8f5-3668-4492-9f3a-59f7df2bbacb/20000101_0_10_1/ in table test_9.modify_sample_replicated (b05fe8f5-3668-4492-9f3a-59f7df2bbacb) located on disk default of type local, from mark 0 with max_rows_to_read = 110): While executing MergeTreeSelect(pool: ReadPoolParallelReplicas, algorithm: Thread). (CANNOT_SCHEDULE_TASK), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000fccaeeb 4. /build/src/Common/ThreadPool.cpp:275: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000fccc813 5. /build/src/Common/ThreadPool.cpp:323: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fcc7bbc 6. /build/src/Common/ThreadPool.cpp:494: ThreadPoolImpl>::scheduleOrThrowOnError(std::function, Priority) @ 0x000000000fcc7a0e 7. /build/src/Common/threadPoolCallbackRunner.h:52: std::function (std::function&&, Priority)> DB::threadPoolCallbackRunnerUnsafe>(ThreadPoolImpl>&, String const&)::'lambda'(std::function&&, Priority)::operator()(std::function&&, Priority) @ 0x000000001320131a 8. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: std::future std::__function::__policy_invoker (std::function&&, Priority)>::__call_impl[abi:se190107] (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&&) @ 0x000000001320110f 9. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000132002ce 10. /build/src/IO/AsynchronousReadBufferFromFileDescriptor.cpp:62: DB::AsynchronousReadBufferFromFileDescriptor::asyncReadInto(char*, unsigned long, Priority) @ 0x00000000131f77d0 11. /build/src/IO/AsynchronousReadBufferFromFileDescriptor.cpp:100: DB::AsynchronousReadBufferFromFileDescriptor::nextImpl() @ 0x00000000131f7acb 12. /build/src/IO/ReadBuffer.h:60: DB::ReadBuffer::next() @ 0x000000000a148c7b 13. /build/src/IO/ReadBuffer.h:96: DB::CompressedReadBufferBase::readCompressedData(unsigned long&, unsigned long&, bool) @ 0x0000000017935e2b 14. /build/src/Compression/CompressedReadBufferFromFile.cpp:25: DB::CompressedReadBufferFromFile::nextImpl() @ 0x0000000017937a5d 15. /build/src/IO/ReadBuffer.h:60: DB::ReadBuffer::next() @ 0x000000000a148c7b 16. /build/src/IO/ReadBuffer.h:96: DB::MergeTreeMarksLoader::loadMarksImpl() @ 0x00000000164731f2 17. /build/src/Storages/MergeTree/MergeTreeMarksLoader.cpp:232: DB::MergeTreeMarksLoader::loadMarksSync() @ 0x000000001647232a 18. /build/src/Storages/MergeTree/MergeTreeMarksLoader.cpp:268: std::__packaged_task_func> (DB::MergeTreeMarksLoader::loadMarksAsync()::$_0&&, Priority)> DB::threadPoolCallbackRunnerUnsafe, DB::MergeTreeMarksLoader::loadMarksAsync()::$_0>(ThreadPoolImpl>&, String const&)::'lambda'(DB::MergeTreeMarksLoader::loadMarksAsync()::$_0&&, Priority)::operator()(DB::MergeTreeMarksLoader::loadMarksAsync()::$_0&&, Priority)::'lambda'(), std::allocator> (DB::MergeTreeMarksLoader::loadMarksAsync()::$_0&&, Priority)> DB::threadPoolCallbackRunnerUnsafe, DB::MergeTreeMarksLoader::loadMarksAsync()::$_0>(ThreadPoolImpl>&, String const&)::'lambda'(DB::MergeTreeMarksLoader::loadMarksAsync()::$_0&&, Priority)::operator()(DB::MergeTreeMarksLoader::loadMarksAsync()::$_0&&, Priority)::'lambda'()>, std::shared_ptr ()>::operator()() @ 0x0000000016474b84 19. /build/contrib/llvm-project/libcxx/include/future:1589: std::packaged_task ()>::operator()() @ 0x000000001647685f 20. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc6653 21. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000000fccc4c3 22. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc3d92 23. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fcca080 24. ? @ 0x00007fbc6213eac3 25. ? @ 0x00007fbc621d0850 Job's origin stack trace: 0. /build/src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000000fc33b84 1. /build/src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000000fcc2ea7 2. /build/src/Common/ThreadPool.cpp:401: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fcc7f1c 3. /build/src/Common/ThreadPool.cpp:494: ThreadPoolImpl>::scheduleOrThrowOnError(std::function, Priority) @ 0x000000000fcc7a0e 4. /build/src/Common/threadPoolCallbackRunner.h:52: std::future> std::__function::__policy_invoker> (DB::MergeTreeMarksLoader::loadMarksAsync()::$_0&&, Priority)>::__call_impl[abi:se190107]> (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&&) @ 0x0000000016474731 5. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000016471940 6. /build/src/Storages/MergeTree/MergeTreeMarksLoader.cpp:83: DB::MergeTreeMarksLoader::startAsyncLoad() @ 0x000000001647173f 7. /build/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) @ 0x000000001648df37 8. /build/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&&) @ 0x00000000163c608d 9. /build/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 @ 0x00000000163c27d4 10. /build/src/Storages/MergeTree/MergeTreeReadTask.cpp:60: DB::MergeTreeReadTask::createReaders(std::shared_ptr const&, DB::MergeTreeReadTask::Extras const&, DB::MarkRanges const&) @ 0x00000000164b5386 11. /build/src/Storages/MergeTree/MergeTreeReadPoolBase.cpp:274: DB::MergeTreeReadPoolBase::createTask(std::shared_ptr, DB::MarkRanges, DB::MergeTreeReadTask*) const @ 0x0000000016e53b1f 12. /build/src/Storages/MergeTree/MergeTreeReadPoolParallelReplicas.cpp:205: DB::MergeTreeReadPoolParallelReplicas::getTask(unsigned long, DB::MergeTreeReadTask*) @ 0x0000000016e6f59a 13. /build/src/Storages/MergeTree/MergeTreeSelectProcessor.cpp:191: DB::MergeTreeSelectProcessor::read() @ 0x00000000164c0b40 14. /build/src/Storages/MergeTree/MergeTreeSource.cpp:229: DB::MergeTreeSource::tryGenerate() @ 0x0000000016e43d69 15. /build/src/Processors/ISource.cpp:108: DB::ISource::work() @ 0x00000000169a21e7 16. /build/src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x00000000169bd00f 17. /build/src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x00000000169b2105 18. /build/src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeSingleThread(unsigned long) @ 0x00000000169b23be 19. /build/src/Processors/Executors/PipelineExecutor.cpp:416: void std::__function::__policy_invoker::__call_impl[abi:se190107]>(std::__function::__policy_storage const*) @ 0x00000000169b2e3f 20. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc6653 21. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000000fccc4c3 22. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc3d92 23. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fcca080 24. ? @ 0x00007fbc6213eac3 25. ? @ 0x00007fbc621d0850 Job's origin stack trace: 0. /build/src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000000fc33b84 1. /build/src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000000fcc2ea7 2. /build/src/Common/ThreadPool.cpp:401: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fcc7f1c 3. /build/src/Common/ThreadPool.cpp:494: ThreadPoolImpl>::scheduleOrThrowOnError(std::function, Priority) @ 0x000000000fcc7a0e 4. /build/src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::spawnThreadsImpl() @ 0x00000000169b2c0c 5. /build/src/Processors/Executors/PipelineExecutor.cpp:394: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x00000000169b0ba7 6. /build/src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x00000000169b03f4 7. /build/src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:se190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169bfeab 8. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc3d92 9. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fcca080 10. ? @ 0x00007fbc6213eac3 11. ? @ 0x00007fbc621d0850 Job's origin stack trace: 0. /build/src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000000fc33b84 1. /build/src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000000fcc2ea7 2. /build/src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fcc535c 3. /build/src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000000fcc584d 4. /build/src/Common/ThreadPool.h:279: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x00000000169bf193 5. /build/src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x00000000169bf518 6. /build/src/Server/TCPHandler.cpp:1237: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x00000000168f1525 7. /build/src/Server/TCPHandler.cpp:678: DB::TCPHandler::runImpl() @ 0x00000000168e68e5 8. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 9. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 10. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 11. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 12. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 13. ? @ 0x00007fbc6213eac3 14. ? @ 0x00007fbc621d0850 2025.07.28 12:03:22.739900 [ 62058 ] {9b2ed78a-de51-409d-8164-56a18d70c911} executeQuery: Code: 57. DB::Exception: Table test_9.test already exists. (TABLE_ALREADY_EXISTS) (version 25.3.6.10636.altinitytest (altinity build)) (from [::1]:38982) (comment: 00543_null_and_prewhere.sql) (query 2, line 3) (in query: CREATE TABLE test ( dt Date, id UInt32, val Nullable(UInt32) ) ENGINE = MergeTree(dt, id, 8192);), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000a06a8eb 4. /build/src/Interpreters/InterpreterCreateQuery.cpp:1824: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x0000000014901d53 5. /build/src/Interpreters/InterpreterCreateQuery.cpp:1743: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000148f9aa9 6. /build/src/Interpreters/InterpreterCreateQuery.cpp:2352: DB::InterpreterCreateQuery::execute() @ 0x0000000014905a41 7. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88dc9 8. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 9. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 10. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 11. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 12. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 13. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 14. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 15. ? @ 0x00007fbc6213eac3 16. ? @ 0x00007fbc621d0850 2025.07.28 12:03:22.743861 [ 62058 ] {} 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. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000a06a8eb 4. /build/src/Interpreters/InterpreterCreateQuery.cpp:1824: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x0000000014901d53 5. /build/src/Interpreters/InterpreterCreateQuery.cpp:1743: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000148f9aa9 6. /build/src/Interpreters/InterpreterCreateQuery.cpp:2352: DB::InterpreterCreateQuery::execute() @ 0x0000000014905a41 7. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88dc9 8. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 9. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 10. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 11. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 12. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 13. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 14. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 15. ? @ 0x00007fbc6213eac3 16. ? @ 0x00007fbc621d0850 2025.07.28 12:03:23.158329 [ 3974 ] {} test_13.rmt2 (7f9b740d-015c-470e-8cc6-8ba33be0dc63): auto DB::StorageReplicatedMergeTree::processQueueEntry(ReplicatedMergeTreeQueue::SelectedEntryPtr)::(anonymous class)::operator()(LogEntryPtr &) const: Code: 86. DB::HTTPException: Received error from remote server http://146b4357c08d:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Ftest%2F01165%2Ftest_13%2Frmt%2Freplicas%2F1&part=20250728_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.6.10636.altinitytest (altinity build)) '. (RECEIVED_ERROR_FROM_REMOTE_IO_SERVER), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.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 const&, int&&, String const&, unsigned long&&, String const&) @ 0x000000000feda8d9 4. /build/src/IO/HTTPCommon.cpp:104: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x000000000feda6e2 5. /build/src/IO/HTTPCommon.cpp:93: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x000000000feda537 6. /build/src/IO/ReadWriteBufferFromHTTP.cpp:277: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x000000001184a4c4 7. /build/src/IO/ReadWriteBufferFromHTTP.cpp:285: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x000000001184a615 8. /build/src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x000000001184ae59 9. /build/src/IO/ReadWriteBufferFromHTTP.cpp:472: void std::__function::__policy_invoker::__call_impl[abi:se190107]>(std::__function::__policy_storage const*) @ 0x000000001184cedd 10. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001184858b 11. /build/src/IO/ReadWriteBufferFromHTTP.cpp:465: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x000000001184bf0b 12. /build/src/IO/ReadBuffer.h:60: DB::ReadBuffer::next() @ 0x000000000a148c7b 13. /build/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) @ 0x0000000011849fb2 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]>&)>&, 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&) @ 0x0000000011841980 15. /build/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) @ 0x000000001621208e 16. /build/src/Storages/StorageReplicatedMergeTree.cpp:5228: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl[abi:se190107] const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000015f9a5fe 17. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000015ed8bfd 18. /build/src/Storages/StorageReplicatedMergeTree.cpp:2514: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x0000000015ec9aab 19. /build/src/Storages/StorageReplicatedMergeTree.cpp:2349: DB::StorageReplicatedMergeTree::executeLogEntry(DB::ReplicatedMergeTreeLogEntry&) @ 0x0000000015eba91b 20. /build/src/Storages/StorageReplicatedMergeTree.cpp:3876: bool std::__function::__policy_invoker&)>::__call_impl[abi:se190107])::$_1, bool (std::shared_ptr&)>>(std::__function::__policy_storage const*, std::shared_ptr&) @ 0x0000000015f9837e 21. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000165d6fc3 22. /build/src/Storages/StorageReplicatedMergeTree.cpp:3872: DB::StorageReplicatedMergeTree::processQueueEntry(std::shared_ptr) @ 0x0000000015efc18a 23. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001624c1b2 24. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000162f9c70 25. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x00000000162fa55a 26. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc6653 27. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000000fccc4c3 28. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc3d92 29. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fcca080 30. ? @ 0x00007fbc6213eac3 31. ? @ 0x00007fbc621d0850 (version 25.3.6.10636.altinitytest (altinity build)) 2025.07.28 12:03:24.308727 [ 3977 ] {} test_13.rmt2 (7f9b740d-015c-470e-8cc6-8ba33be0dc63): auto DB::StorageReplicatedMergeTree::processQueueEntry(ReplicatedMergeTreeQueue::SelectedEntryPtr)::(anonymous class)::operator()(LogEntryPtr &) const: Code: 86. DB::HTTPException: Received error from remote server http://146b4357c08d:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Ftest%2F01165%2Ftest_13%2Frmt%2Freplicas%2F1&part=20250728_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.6.10636.altinitytest (altinity build)) '. (RECEIVED_ERROR_FROM_REMOTE_IO_SERVER), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.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 const&, int&&, String const&, unsigned long&&, String const&) @ 0x000000000feda8d9 4. /build/src/IO/HTTPCommon.cpp:104: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x000000000feda6e2 5. /build/src/IO/HTTPCommon.cpp:93: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x000000000feda537 6. /build/src/IO/ReadWriteBufferFromHTTP.cpp:277: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x000000001184a4c4 7. /build/src/IO/ReadWriteBufferFromHTTP.cpp:285: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x000000001184a615 8. /build/src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x000000001184ae59 9. /build/src/IO/ReadWriteBufferFromHTTP.cpp:472: void std::__function::__policy_invoker::__call_impl[abi:se190107]>(std::__function::__policy_storage const*) @ 0x000000001184cedd 10. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001184858b 11. /build/src/IO/ReadWriteBufferFromHTTP.cpp:465: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x000000001184bf0b 12. /build/src/IO/ReadBuffer.h:60: DB::ReadBuffer::next() @ 0x000000000a148c7b 13. /build/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) @ 0x0000000011849fb2 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]>&)>&, 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&) @ 0x0000000011841980 15. /build/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) @ 0x000000001621208e 16. /build/src/Storages/StorageReplicatedMergeTree.cpp:5228: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl[abi:se190107] const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000015f9a5fe 17. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000015ed8bfd 18. /build/src/Storages/StorageReplicatedMergeTree.cpp:2514: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x0000000015ec9aab 19. /build/src/Storages/StorageReplicatedMergeTree.cpp:2349: DB::StorageReplicatedMergeTree::executeLogEntry(DB::ReplicatedMergeTreeLogEntry&) @ 0x0000000015eba91b 20. /build/src/Storages/StorageReplicatedMergeTree.cpp:3876: bool std::__function::__policy_invoker&)>::__call_impl[abi:se190107])::$_1, bool (std::shared_ptr&)>>(std::__function::__policy_storage const*, std::shared_ptr&) @ 0x0000000015f9837e 21. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000165d6fc3 22. /build/src/Storages/StorageReplicatedMergeTree.cpp:3872: DB::StorageReplicatedMergeTree::processQueueEntry(std::shared_ptr) @ 0x0000000015efc18a 23. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001624c1b2 24. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000162f9c70 25. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x00000000162fa55a 26. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc6653 27. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000000fccc4c3 28. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc3d92 29. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fcca080 30. ? @ 0x00007fbc6213eac3 31. ? @ 0x00007fbc621d0850 (version 25.3.6.10636.altinitytest (altinity build)) 2025.07.28 12:03:24.661204 [ 3965 ] {} test_13.rmt2 (7f9b740d-015c-470e-8cc6-8ba33be0dc63): auto DB::StorageReplicatedMergeTree::processQueueEntry(ReplicatedMergeTreeQueue::SelectedEntryPtr)::(anonymous class)::operator()(LogEntryPtr &) const: Code: 86. DB::HTTPException: Received error from remote server http://146b4357c08d:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Ftest%2F01165%2Ftest_13%2Frmt%2Freplicas%2F1&part=20250728_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.6.10636.altinitytest (altinity build)) '. (RECEIVED_ERROR_FROM_REMOTE_IO_SERVER), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.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 const&, int&&, String const&, unsigned long&&, String const&) @ 0x000000000feda8d9 4. /build/src/IO/HTTPCommon.cpp:104: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x000000000feda6e2 5. /build/src/IO/HTTPCommon.cpp:93: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x000000000feda537 6. /build/src/IO/ReadWriteBufferFromHTTP.cpp:277: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x000000001184a4c4 7. /build/src/IO/ReadWriteBufferFromHTTP.cpp:285: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x000000001184a615 8. /build/src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x000000001184ae59 9. /build/src/IO/ReadWriteBufferFromHTTP.cpp:472: void std::__function::__policy_invoker::__call_impl[abi:se190107]>(std::__function::__policy_storage const*) @ 0x000000001184cedd 10. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001184858b 11. /build/src/IO/ReadWriteBufferFromHTTP.cpp:465: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x000000001184bf0b 12. /build/src/IO/ReadBuffer.h:60: DB::ReadBuffer::next() @ 0x000000000a148c7b 13. /build/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) @ 0x0000000011849fb2 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]>&)>&, 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&) @ 0x0000000011841980 15. /build/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) @ 0x000000001621208e 16. /build/src/Storages/StorageReplicatedMergeTree.cpp:5228: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl[abi:se190107] const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000015f9a5fe 17. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000015ed8bfd 18. /build/src/Storages/StorageReplicatedMergeTree.cpp:2514: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x0000000015ec9aab 19. /build/src/Storages/StorageReplicatedMergeTree.cpp:2349: DB::StorageReplicatedMergeTree::executeLogEntry(DB::ReplicatedMergeTreeLogEntry&) @ 0x0000000015eba91b 20. /build/src/Storages/StorageReplicatedMergeTree.cpp:3876: bool std::__function::__policy_invoker&)>::__call_impl[abi:se190107])::$_1, bool (std::shared_ptr&)>>(std::__function::__policy_storage const*, std::shared_ptr&) @ 0x0000000015f9837e 21. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000165d6fc3 22. /build/src/Storages/StorageReplicatedMergeTree.cpp:3872: DB::StorageReplicatedMergeTree::processQueueEntry(std::shared_ptr) @ 0x0000000015efc18a 23. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001624c1b2 24. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000162f9c70 25. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x00000000162fa55a 26. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc6653 27. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000000fccc4c3 28. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc3d92 29. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fcca080 30. ? @ 0x00007fbc6213eac3 31. ? @ 0x00007fbc621d0850 (version 25.3.6.10636.altinitytest (altinity build)) 2025.07.28 12:03:25.055415 [ 3968 ] {} test_13.rmt2 (7f9b740d-015c-470e-8cc6-8ba33be0dc63): auto DB::StorageReplicatedMergeTree::processQueueEntry(ReplicatedMergeTreeQueue::SelectedEntryPtr)::(anonymous class)::operator()(LogEntryPtr &) const: Code: 86. DB::HTTPException: Received error from remote server http://146b4357c08d:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Ftest%2F01165%2Ftest_13%2Frmt%2Freplicas%2F1&part=20250728_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.6.10636.altinitytest (altinity build)) '. (RECEIVED_ERROR_FROM_REMOTE_IO_SERVER), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.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 const&, int&&, String const&, unsigned long&&, String const&) @ 0x000000000feda8d9 4. /build/src/IO/HTTPCommon.cpp:104: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x000000000feda6e2 5. /build/src/IO/HTTPCommon.cpp:93: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x000000000feda537 6. /build/src/IO/ReadWriteBufferFromHTTP.cpp:277: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x000000001184a4c4 7. /build/src/IO/ReadWriteBufferFromHTTP.cpp:285: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x000000001184a615 8. /build/src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x000000001184ae59 9. /build/src/IO/ReadWriteBufferFromHTTP.cpp:472: void std::__function::__policy_invoker::__call_impl[abi:se190107]>(std::__function::__policy_storage const*) @ 0x000000001184cedd 10. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001184858b 11. /build/src/IO/ReadWriteBufferFromHTTP.cpp:465: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x000000001184bf0b 12. /build/src/IO/ReadBuffer.h:60: DB::ReadBuffer::next() @ 0x000000000a148c7b 13. /build/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) @ 0x0000000011849fb2 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]>&)>&, 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&) @ 0x0000000011841980 15. /build/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) @ 0x000000001621208e 16. /build/src/Storages/StorageReplicatedMergeTree.cpp:5228: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl[abi:se190107] const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000015f9a5fe 17. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000015ed8bfd 18. /build/src/Storages/StorageReplicatedMergeTree.cpp:2514: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x0000000015ec9aab 19. /build/src/Storages/StorageReplicatedMergeTree.cpp:2349: DB::StorageReplicatedMergeTree::executeLogEntry(DB::ReplicatedMergeTreeLogEntry&) @ 0x0000000015eba91b 20. /build/src/Storages/StorageReplicatedMergeTree.cpp:3876: bool std::__function::__policy_invoker&)>::__call_impl[abi:se190107])::$_1, bool (std::shared_ptr&)>>(std::__function::__policy_storage const*, std::shared_ptr&) @ 0x0000000015f9837e 21. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000165d6fc3 22. /build/src/Storages/StorageReplicatedMergeTree.cpp:3872: DB::StorageReplicatedMergeTree::processQueueEntry(std::shared_ptr) @ 0x0000000015efc18a 23. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001624c1b2 24. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000162f9c70 25. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x00000000162fa55a 26. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc6653 27. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000000fccc4c3 28. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc3d92 29. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fcca080 30. ? @ 0x00007fbc6213eac3 31. ? @ 0x00007fbc621d0850 (version 25.3.6.10636.altinitytest (altinity build)) 2025.07.28 12:03:25.138782 [ 3974 ] {} test_13.rmt2 (7f9b740d-015c-470e-8cc6-8ba33be0dc63): auto DB::StorageReplicatedMergeTree::processQueueEntry(ReplicatedMergeTreeQueue::SelectedEntryPtr)::(anonymous class)::operator()(LogEntryPtr &) const: Code: 86. DB::HTTPException: Received error from remote server http://146b4357c08d:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Ftest%2F01165%2Ftest_13%2Frmt%2Freplicas%2F1&part=20250728_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.6.10636.altinitytest (altinity build)) '. (RECEIVED_ERROR_FROM_REMOTE_IO_SERVER), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.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 const&, int&&, String const&, unsigned long&&, String const&) @ 0x000000000feda8d9 4. /build/src/IO/HTTPCommon.cpp:104: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x000000000feda6e2 5. /build/src/IO/HTTPCommon.cpp:93: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x000000000feda537 6. /build/src/IO/ReadWriteBufferFromHTTP.cpp:277: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x000000001184a4c4 7. /build/src/IO/ReadWriteBufferFromHTTP.cpp:285: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x000000001184a615 8. /build/src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x000000001184ae59 9. /build/src/IO/ReadWriteBufferFromHTTP.cpp:472: void std::__function::__policy_invoker::__call_impl[abi:se190107]>(std::__function::__policy_storage const*) @ 0x000000001184cedd 10. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001184858b 11. /build/src/IO/ReadWriteBufferFromHTTP.cpp:465: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x000000001184bf0b 12. /build/src/IO/ReadBuffer.h:60: DB::ReadBuffer::next() @ 0x000000000a148c7b 13. /build/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) @ 0x0000000011849fb2 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]>&)>&, 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&) @ 0x0000000011841980 15. /build/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) @ 0x000000001621208e 16. /build/src/Storages/StorageReplicatedMergeTree.cpp:5228: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl[abi:se190107] const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000015f9a5fe 17. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000015ed8bfd 18. /build/src/Storages/StorageReplicatedMergeTree.cpp:2514: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x0000000015ec9aab 19. /build/src/Storages/StorageReplicatedMergeTree.cpp:2349: DB::StorageReplicatedMergeTree::executeLogEntry(DB::ReplicatedMergeTreeLogEntry&) @ 0x0000000015eba91b 20. /build/src/Storages/StorageReplicatedMergeTree.cpp:3876: bool std::__function::__policy_invoker&)>::__call_impl[abi:se190107])::$_1, bool (std::shared_ptr&)>>(std::__function::__policy_storage const*, std::shared_ptr&) @ 0x0000000015f9837e 21. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000165d6fc3 22. /build/src/Storages/StorageReplicatedMergeTree.cpp:3872: DB::StorageReplicatedMergeTree::processQueueEntry(std::shared_ptr) @ 0x0000000015efc18a 23. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001624c1b2 24. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000162f9c70 25. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x00000000162fa55a 26. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc6653 27. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000000fccc4c3 28. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc3d92 29. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fcca080 30. ? @ 0x00007fbc6213eac3 31. ? @ 0x00007fbc621d0850 (version 25.3.6.10636.altinitytest (altinity build)) 2025.07.28 12:03:26.041629 [ 3962 ] {} test_13.rmt2 (7f9b740d-015c-470e-8cc6-8ba33be0dc63): auto DB::StorageReplicatedMergeTree::processQueueEntry(ReplicatedMergeTreeQueue::SelectedEntryPtr)::(anonymous class)::operator()(LogEntryPtr &) const: Code: 86. DB::HTTPException: Received error from remote server http://146b4357c08d:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Ftest%2F01165%2Ftest_13%2Frmt%2Freplicas%2F1&part=20250728_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.6.10636.altinitytest (altinity build)) '. (RECEIVED_ERROR_FROM_REMOTE_IO_SERVER), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.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 const&, int&&, String const&, unsigned long&&, String const&) @ 0x000000000feda8d9 4. /build/src/IO/HTTPCommon.cpp:104: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x000000000feda6e2 5. /build/src/IO/HTTPCommon.cpp:93: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x000000000feda537 6. /build/src/IO/ReadWriteBufferFromHTTP.cpp:277: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x000000001184a4c4 7. /build/src/IO/ReadWriteBufferFromHTTP.cpp:285: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x000000001184a615 8. /build/src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x000000001184ae59 9. /build/src/IO/ReadWriteBufferFromHTTP.cpp:472: void std::__function::__policy_invoker::__call_impl[abi:se190107]>(std::__function::__policy_storage const*) @ 0x000000001184cedd 10. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001184858b 11. /build/src/IO/ReadWriteBufferFromHTTP.cpp:465: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x000000001184bf0b 12. /build/src/IO/ReadBuffer.h:60: DB::ReadBuffer::next() @ 0x000000000a148c7b 13. /build/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) @ 0x0000000011849fb2 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]>&)>&, 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&) @ 0x0000000011841980 15. /build/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) @ 0x000000001621208e 16. /build/src/Storages/StorageReplicatedMergeTree.cpp:5228: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl[abi:se190107] const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000015f9a5fe 17. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000015ed8bfd 18. /build/src/Storages/StorageReplicatedMergeTree.cpp:2514: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x0000000015ec9aab 19. /build/src/Storages/StorageReplicatedMergeTree.cpp:2349: DB::StorageReplicatedMergeTree::executeLogEntry(DB::ReplicatedMergeTreeLogEntry&) @ 0x0000000015eba91b 20. /build/src/Storages/StorageReplicatedMergeTree.cpp:3876: bool std::__function::__policy_invoker&)>::__call_impl[abi:se190107])::$_1, bool (std::shared_ptr&)>>(std::__function::__policy_storage const*, std::shared_ptr&) @ 0x0000000015f9837e 21. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000165d6fc3 22. /build/src/Storages/StorageReplicatedMergeTree.cpp:3872: DB::StorageReplicatedMergeTree::processQueueEntry(std::shared_ptr) @ 0x0000000015efc18a 23. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001624c1b2 24. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000162f9c70 25. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x00000000162fa55a 26. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc6653 27. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000000fccc4c3 28. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc3d92 29. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fcca080 30. ? @ 0x00007fbc6213eac3 31. ? @ 0x00007fbc621d0850 (version 25.3.6.10636.altinitytest (altinity build)) 2025.07.28 12:03:26.861690 [ 3965 ] {} test_13.rmt2 (7f9b740d-015c-470e-8cc6-8ba33be0dc63): auto DB::StorageReplicatedMergeTree::processQueueEntry(ReplicatedMergeTreeQueue::SelectedEntryPtr)::(anonymous class)::operator()(LogEntryPtr &) const: Code: 86. DB::HTTPException: Received error from remote server http://146b4357c08d:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Ftest%2F01165%2Ftest_13%2Frmt%2Freplicas%2F1&part=20250728_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.6.10636.altinitytest (altinity build)) '. (RECEIVED_ERROR_FROM_REMOTE_IO_SERVER), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.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 const&, int&&, String const&, unsigned long&&, String const&) @ 0x000000000feda8d9 4. /build/src/IO/HTTPCommon.cpp:104: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x000000000feda6e2 5. /build/src/IO/HTTPCommon.cpp:93: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x000000000feda537 6. /build/src/IO/ReadWriteBufferFromHTTP.cpp:277: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x000000001184a4c4 7. /build/src/IO/ReadWriteBufferFromHTTP.cpp:285: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x000000001184a615 8. /build/src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x000000001184ae59 9. /build/src/IO/ReadWriteBufferFromHTTP.cpp:472: void std::__function::__policy_invoker::__call_impl[abi:se190107]>(std::__function::__policy_storage const*) @ 0x000000001184cedd 10. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001184858b 11. /build/src/IO/ReadWriteBufferFromHTTP.cpp:465: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x000000001184bf0b 12. /build/src/IO/ReadBuffer.h:60: DB::ReadBuffer::next() @ 0x000000000a148c7b 13. /build/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) @ 0x0000000011849fb2 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]>&)>&, 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&) @ 0x0000000011841980 15. /build/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) @ 0x000000001621208e 16. /build/src/Storages/StorageReplicatedMergeTree.cpp:5228: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl[abi:se190107] const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000015f9a5fe 17. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000015ed8bfd 18. /build/src/Storages/StorageReplicatedMergeTree.cpp:2514: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x0000000015ec9aab 19. /build/src/Storages/StorageReplicatedMergeTree.cpp:2349: DB::StorageReplicatedMergeTree::executeLogEntry(DB::ReplicatedMergeTreeLogEntry&) @ 0x0000000015eba91b 20. /build/src/Storages/StorageReplicatedMergeTree.cpp:3876: bool std::__function::__policy_invoker&)>::__call_impl[abi:se190107])::$_1, bool (std::shared_ptr&)>>(std::__function::__policy_storage const*, std::shared_ptr&) @ 0x0000000015f9837e 21. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000165d6fc3 22. /build/src/Storages/StorageReplicatedMergeTree.cpp:3872: DB::StorageReplicatedMergeTree::processQueueEntry(std::shared_ptr) @ 0x0000000015efc18a 23. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001624c1b2 24. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000162f9c70 25. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x00000000162fa55a 26. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc6653 27. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000000fccc4c3 28. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc3d92 29. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fcca080 30. ? @ 0x00007fbc6213eac3 31. ? @ 0x00007fbc621d0850 (version 25.3.6.10636.altinitytest (altinity build)) 2025.07.28 12:03:27.107610 [ 3970 ] {} test_13.rmt2 (7f9b740d-015c-470e-8cc6-8ba33be0dc63): auto DB::StorageReplicatedMergeTree::processQueueEntry(ReplicatedMergeTreeQueue::SelectedEntryPtr)::(anonymous class)::operator()(LogEntryPtr &) const: Code: 86. DB::HTTPException: Received error from remote server http://146b4357c08d:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Ftest%2F01165%2Ftest_13%2Frmt%2Freplicas%2F1&part=20250728_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.6.10636.altinitytest (altinity build)) '. (RECEIVED_ERROR_FROM_REMOTE_IO_SERVER), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.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 const&, int&&, String const&, unsigned long&&, String const&) @ 0x000000000feda8d9 4. /build/src/IO/HTTPCommon.cpp:104: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x000000000feda6e2 5. /build/src/IO/HTTPCommon.cpp:93: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x000000000feda537 6. /build/src/IO/ReadWriteBufferFromHTTP.cpp:277: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x000000001184a4c4 7. /build/src/IO/ReadWriteBufferFromHTTP.cpp:285: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x000000001184a615 8. /build/src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x000000001184ae59 9. /build/src/IO/ReadWriteBufferFromHTTP.cpp:472: void std::__function::__policy_invoker::__call_impl[abi:se190107]>(std::__function::__policy_storage const*) @ 0x000000001184cedd 10. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001184858b 11. /build/src/IO/ReadWriteBufferFromHTTP.cpp:465: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x000000001184bf0b 12. /build/src/IO/ReadBuffer.h:60: DB::ReadBuffer::next() @ 0x000000000a148c7b 13. /build/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) @ 0x0000000011849fb2 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]>&)>&, 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&) @ 0x0000000011841980 15. /build/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) @ 0x000000001621208e 16. /build/src/Storages/StorageReplicatedMergeTree.cpp:5228: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl[abi:se190107] const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000015f9a5fe 17. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000015ed8bfd 18. /build/src/Storages/StorageReplicatedMergeTree.cpp:2514: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x0000000015ec9aab 19. /build/src/Storages/StorageReplicatedMergeTree.cpp:2349: DB::StorageReplicatedMergeTree::executeLogEntry(DB::ReplicatedMergeTreeLogEntry&) @ 0x0000000015eba91b 20. /build/src/Storages/StorageReplicatedMergeTree.cpp:3876: bool std::__function::__policy_invoker&)>::__call_impl[abi:se190107])::$_1, bool (std::shared_ptr&)>>(std::__function::__policy_storage const*, std::shared_ptr&) @ 0x0000000015f9837e 21. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000165d6fc3 22. /build/src/Storages/StorageReplicatedMergeTree.cpp:3872: DB::StorageReplicatedMergeTree::processQueueEntry(std::shared_ptr) @ 0x0000000015efc18a 23. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001624c1b2 24. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000162f9c70 25. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x00000000162fa55a 26. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc6653 27. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000000fccc4c3 28. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc3d92 29. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fcca080 30. ? @ 0x00007fbc6213eac3 31. ? @ 0x00007fbc621d0850 (version 25.3.6.10636.altinitytest (altinity build)) 2025.07.28 12:03:27.770955 [ 3967 ] {} test_13.rmt2 (7f9b740d-015c-470e-8cc6-8ba33be0dc63): auto DB::StorageReplicatedMergeTree::processQueueEntry(ReplicatedMergeTreeQueue::SelectedEntryPtr)::(anonymous class)::operator()(LogEntryPtr &) const: Code: 86. DB::HTTPException: Received error from remote server http://146b4357c08d:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Ftest%2F01165%2Ftest_13%2Frmt%2Freplicas%2F1&part=20250728_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.6.10636.altinitytest (altinity build)) '. (RECEIVED_ERROR_FROM_REMOTE_IO_SERVER), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.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 const&, int&&, String const&, unsigned long&&, String const&) @ 0x000000000feda8d9 4. /build/src/IO/HTTPCommon.cpp:104: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x000000000feda6e2 5. /build/src/IO/HTTPCommon.cpp:93: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x000000000feda537 6. /build/src/IO/ReadWriteBufferFromHTTP.cpp:277: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x000000001184a4c4 7. /build/src/IO/ReadWriteBufferFromHTTP.cpp:285: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x000000001184a615 8. /build/src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x000000001184ae59 9. /build/src/IO/ReadWriteBufferFromHTTP.cpp:472: void std::__function::__policy_invoker::__call_impl[abi:se190107]>(std::__function::__policy_storage const*) @ 0x000000001184cedd 10. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001184858b 11. /build/src/IO/ReadWriteBufferFromHTTP.cpp:465: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x000000001184bf0b 12. /build/src/IO/ReadBuffer.h:60: DB::ReadBuffer::next() @ 0x000000000a148c7b 13. /build/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) @ 0x0000000011849fb2 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]>&)>&, 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&) @ 0x0000000011841980 15. /build/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) @ 0x000000001621208e 16. /build/src/Storages/StorageReplicatedMergeTree.cpp:5228: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl[abi:se190107] const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000015f9a5fe 17. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000015ed8bfd 18. /build/src/Storages/StorageReplicatedMergeTree.cpp:2514: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x0000000015ec9aab 19. /build/src/Storages/StorageReplicatedMergeTree.cpp:2349: DB::StorageReplicatedMergeTree::executeLogEntry(DB::ReplicatedMergeTreeLogEntry&) @ 0x0000000015eba91b 20. /build/src/Storages/StorageReplicatedMergeTree.cpp:3876: bool std::__function::__policy_invoker&)>::__call_impl[abi:se190107])::$_1, bool (std::shared_ptr&)>>(std::__function::__policy_storage const*, std::shared_ptr&) @ 0x0000000015f9837e 21. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000165d6fc3 22. /build/src/Storages/StorageReplicatedMergeTree.cpp:3872: DB::StorageReplicatedMergeTree::processQueueEntry(std::shared_ptr) @ 0x0000000015efc18a 23. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001624c1b2 24. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000162f9c70 25. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x00000000162fa55a 26. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc6653 27. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000000fccc4c3 28. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc3d92 29. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fcca080 30. ? @ 0x00007fbc6213eac3 31. ? @ 0x00007fbc621d0850 (version 25.3.6.10636.altinitytest (altinity build)) 2025.07.28 12:03:27.933772 [ 3960 ] {} test_13.rmt2 (7f9b740d-015c-470e-8cc6-8ba33be0dc63): auto DB::StorageReplicatedMergeTree::processQueueEntry(ReplicatedMergeTreeQueue::SelectedEntryPtr)::(anonymous class)::operator()(LogEntryPtr &) const: Code: 86. DB::HTTPException: Received error from remote server http://146b4357c08d:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Ftest%2F01165%2Ftest_13%2Frmt%2Freplicas%2F1&part=20250728_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.6.10636.altinitytest (altinity build)) '. (RECEIVED_ERROR_FROM_REMOTE_IO_SERVER), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.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 const&, int&&, String const&, unsigned long&&, String const&) @ 0x000000000feda8d9 4. /build/src/IO/HTTPCommon.cpp:104: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x000000000feda6e2 5. /build/src/IO/HTTPCommon.cpp:93: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x000000000feda537 6. /build/src/IO/ReadWriteBufferFromHTTP.cpp:277: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x000000001184a4c4 7. /build/src/IO/ReadWriteBufferFromHTTP.cpp:285: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x000000001184a615 8. /build/src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x000000001184ae59 9. /build/src/IO/ReadWriteBufferFromHTTP.cpp:472: void std::__function::__policy_invoker::__call_impl[abi:se190107]>(std::__function::__policy_storage const*) @ 0x000000001184cedd 10. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001184858b 11. /build/src/IO/ReadWriteBufferFromHTTP.cpp:465: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x000000001184bf0b 12. /build/src/IO/ReadBuffer.h:60: DB::ReadBuffer::next() @ 0x000000000a148c7b 13. /build/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) @ 0x0000000011849fb2 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]>&)>&, 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&) @ 0x0000000011841980 15. /build/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) @ 0x000000001621208e 16. /build/src/Storages/StorageReplicatedMergeTree.cpp:5228: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl[abi:se190107] const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000015f9a5fe 17. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000015ed8bfd 18. /build/src/Storages/StorageReplicatedMergeTree.cpp:2514: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x0000000015ec9aab 19. /build/src/Storages/StorageReplicatedMergeTree.cpp:2349: DB::StorageReplicatedMergeTree::executeLogEntry(DB::ReplicatedMergeTreeLogEntry&) @ 0x0000000015eba91b 20. /build/src/Storages/StorageReplicatedMergeTree.cpp:3876: bool std::__function::__policy_invoker&)>::__call_impl[abi:se190107])::$_1, bool (std::shared_ptr&)>>(std::__function::__policy_storage const*, std::shared_ptr&) @ 0x0000000015f9837e 21. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000165d6fc3 22. /build/src/Storages/StorageReplicatedMergeTree.cpp:3872: DB::StorageReplicatedMergeTree::processQueueEntry(std::shared_ptr) @ 0x0000000015efc18a 23. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001624c1b2 24. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000162f9c70 25. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x00000000162fa55a 26. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc6653 27. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000000fccc4c3 28. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc3d92 29. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fcca080 30. ? @ 0x00007fbc6213eac3 31. ? @ 0x00007fbc621d0850 (version 25.3.6.10636.altinitytest (altinity build)) 2025.07.28 12:03:28.054850 [ 11826 ] {d23d8530-65e7-4d02-9292-5ab8dd3b66d3} 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(1, 2, 3). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.6.10636.altinitytest (altinity build)) (from [::1]:39086) (comment: 03130_generateSnowflakeId.sql) (query 2, line 4) (in query: SELECT generateSnowflakeID(1, 2, 3);), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&, String&&) @ 0x0000000012da6feb 4. /build/src/Functions/FunctionHelpers.cpp:184: DB::validateFunctionArguments(DB::IFunction const&, std::vector> const&, std::vector> const&, std::vector> const&) @ 0x0000000012da5831 5. /build/src/Functions/generateSnowflakeID.cpp:172: DB::FunctionGenerateSnowflakeID::getReturnTypeImpl(std::vector> const&) const @ 0x000000000ba4fb67 6. /build/src/Functions/IFunction.cpp:645: DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x0000000012d96b0c 7. /build/src/Functions/IFunction.cpp:577: DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x0000000012d9669c 8. /build/src/Functions/IFunction.cpp:606: DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x0000000012d96edc 9. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3544: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000014033cc9 10. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3838: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000014019a9e 11. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3980: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000014018e31 12. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:4304: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000014042fa7 13. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5605: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000014013749 14. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000140127f9 15. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000014011fce 16. /build/src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000001406ce8a 17. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000014973b42 18. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000001497268d 19. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000014974d24 20. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001492924b 21. /build/src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88641 22. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 23. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 24. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 25. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 26. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 27. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 28. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 29. ? @ 0x00007fbc6213eac3 30. ? @ 0x00007fbc621d0850 2025.07.28 12:03:28.058126 [ 11826 ] {} 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(1, 2, 3). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&, String&&) @ 0x0000000012da6feb 4. /build/src/Functions/FunctionHelpers.cpp:184: DB::validateFunctionArguments(DB::IFunction const&, std::vector> const&, std::vector> const&, std::vector> const&) @ 0x0000000012da5831 5. /build/src/Functions/generateSnowflakeID.cpp:172: DB::FunctionGenerateSnowflakeID::getReturnTypeImpl(std::vector> const&) const @ 0x000000000ba4fb67 6. /build/src/Functions/IFunction.cpp:645: DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x0000000012d96b0c 7. /build/src/Functions/IFunction.cpp:577: DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x0000000012d9669c 8. /build/src/Functions/IFunction.cpp:606: DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x0000000012d96edc 9. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3544: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000014033cc9 10. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3838: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000014019a9e 11. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3980: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000014018e31 12. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:4304: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000014042fa7 13. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5605: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000014013749 14. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000140127f9 15. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000014011fce 16. /build/src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000001406ce8a 17. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000014973b42 18. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000001497268d 19. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000014974d24 20. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001492924b 21. /build/src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88641 22. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 23. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 24. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 25. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 26. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 27. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 28. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 29. ? @ 0x00007fbc6213eac3 30. ? @ 0x00007fbc621d0850 2025.07.28 12:03:28.073403 [ 17232 ] {3450b554-d7f5-4552-a057-29520775c8ef} executeQuery: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=1, jobs=1). (CANNOT_SCHEDULE_TASK) (version 25.3.6.10636.altinitytest (altinity build)) (from [::1]:60948) (comment: 00498_array_functions_concat_slice_push_pop.sql) (query 112, line 121) (in query: select arr1, arrayPushFront(arr1, 0.1) from array_functions;), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000fccaeeb 4. /build/src/Common/ThreadPool.cpp:275: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000fccc813 5. /build/src/Common/ThreadPool.cpp:323: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fcc7bbc 6. /build/src/Common/ThreadPool.cpp:494: ThreadPoolImpl>::scheduleOrThrowOnError(std::function, Priority) @ 0x000000000fcc7a0e 7. /build/src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::spawnThreadsImpl() @ 0x00000000169b2c0c 8. /build/src/Processors/Executors/PipelineExecutor.cpp:394: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x00000000169b0ba7 9. /build/src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x00000000169b03f4 10. /build/src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:se190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169bfeab 11. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc3d92 12. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fcca080 13. ? @ 0x00007fbc6213eac3 14. ? @ 0x00007fbc621d0850 2025.07.28 12:03:28.084190 [ 17232 ] {} 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. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000fccaeeb 4. /build/src/Common/ThreadPool.cpp:275: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000fccc813 5. /build/src/Common/ThreadPool.cpp:323: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fcc7bbc 6. /build/src/Common/ThreadPool.cpp:494: ThreadPoolImpl>::scheduleOrThrowOnError(std::function, Priority) @ 0x000000000fcc7a0e 7. /build/src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::spawnThreadsImpl() @ 0x00000000169b2c0c 8. /build/src/Processors/Executors/PipelineExecutor.cpp:394: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x00000000169b0ba7 9. /build/src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x00000000169b03f4 10. /build/src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:se190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169bfeab 11. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc3d92 12. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fcca080 13. ? @ 0x00007fbc6213eac3 14. ? @ 0x00007fbc621d0850 Job's origin stack trace: 0. /build/src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000000fc33b84 1. /build/src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000000fcc2ea7 2. /build/src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fcc535c 3. /build/src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000000fcc584d 4. /build/src/Common/ThreadPool.h:279: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x00000000169bf193 5. /build/src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x00000000169bf518 6. /build/src/Server/TCPHandler.cpp:1237: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x00000000168f1525 7. /build/src/Server/TCPHandler.cpp:678: DB::TCPHandler::runImpl() @ 0x00000000168e68e5 8. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 9. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 10. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 11. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 12. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 13. ? @ 0x00007fbc6213eac3 14. ? @ 0x00007fbc621d0850 2025.07.28 12:03:28.192602 [ 11826 ] {62d1907d-9738-485b-93b6-6be75eba11c3} executeQuery: Code: 43. DB::Exception: A value of illegal type was provided as 2nd argument 'machine_id' to function 'generateSnowflakeID'. Expected: const UInt*, got: String: In scope SELECT generateSnowflakeID(1, 'not_an_int'). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.6.10636.altinitytest (altinity build)) (from [::1]:39086) (comment: 03130_generateSnowflakeId.sql) (query 3, line 5) (in query: SELECT generateSnowflakeID(1, 'not_an_int');), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: 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&&) @ 0x0000000012da74d9 4. /build/src/Functions/FunctionHelpers.cpp:130: DB::(anonymous namespace)::validateArgumentsImpl(DB::IFunction const&, std::vector> const&, unsigned long, std::vector> const&) @ 0x0000000012da5b15 5. /build/src/Functions/generateSnowflakeID.cpp:172: DB::FunctionGenerateSnowflakeID::getReturnTypeImpl(std::vector> const&) const @ 0x000000000ba4fb67 6. /build/src/Functions/IFunction.cpp:645: DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x0000000012d96b0c 7. /build/src/Functions/IFunction.cpp:577: DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x0000000012d9669c 8. /build/src/Functions/IFunction.cpp:606: DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x0000000012d96edc 9. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3544: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000014033cc9 10. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3838: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000014019a9e 11. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3980: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000014018e31 12. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:4304: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000014042fa7 13. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5605: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000014013749 14. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000140127f9 15. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000014011fce 16. /build/src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000001406ce8a 17. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000014973b42 18. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000001497268d 19. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000014974d24 20. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001492924b 21. /build/src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88641 22. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 23. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 24. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 25. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 26. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 27. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 28. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 29. ? @ 0x00007fbc6213eac3 30. ? @ 0x00007fbc621d0850 2025.07.28 12:03:28.201036 [ 11826 ] {} TCPHandler: Code: 43. DB::Exception: A value of illegal type was provided as 2nd argument 'machine_id' to function 'generateSnowflakeID'. Expected: const UInt*, got: String: In scope SELECT generateSnowflakeID(1, 'not_an_int'). (ILLEGAL_TYPE_OF_ARGUMENT), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: 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&&) @ 0x0000000012da74d9 4. /build/src/Functions/FunctionHelpers.cpp:130: DB::(anonymous namespace)::validateArgumentsImpl(DB::IFunction const&, std::vector> const&, unsigned long, std::vector> const&) @ 0x0000000012da5b15 5. /build/src/Functions/generateSnowflakeID.cpp:172: DB::FunctionGenerateSnowflakeID::getReturnTypeImpl(std::vector> const&) const @ 0x000000000ba4fb67 6. /build/src/Functions/IFunction.cpp:645: DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x0000000012d96b0c 7. /build/src/Functions/IFunction.cpp:577: DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x0000000012d9669c 8. /build/src/Functions/IFunction.cpp:606: DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x0000000012d96edc 9. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3544: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000014033cc9 10. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3838: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000014019a9e 11. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3980: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000014018e31 12. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:4304: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000014042fa7 13. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5605: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000014013749 14. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000140127f9 15. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000014011fce 16. /build/src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000001406ce8a 17. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000014973b42 18. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000001497268d 19. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000014974d24 20. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001492924b 21. /build/src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88641 22. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 23. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 24. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 25. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 26. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 27. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 28. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 29. ? @ 0x00007fbc6213eac3 30. ? @ 0x00007fbc621d0850 2025.07.28 12:03:28.232166 [ 11826 ] {5195a35d-a467-453a-8f05-d0cc5a5eb07a} executeQuery: Code: 44. DB::Exception: A value of illegal type was provided as 2nd argument 'machine_id' to function 'generateSnowflakeID'. Expected: const UInt*, got: UInt8: In scope SELECT generateSnowflakeID(1, materialize(2)). (ILLEGAL_COLUMN) (version 25.3.6.10636.altinitytest (altinity build)) (from [::1]:39086) (comment: 03130_generateSnowflakeId.sql) (query 4, line 6) (in query: SELECT generateSnowflakeID(1, materialize(2));), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: 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&&) @ 0x0000000012da74d9 4. /build/src/Functions/FunctionHelpers.cpp:130: DB::(anonymous namespace)::validateArgumentsImpl(DB::IFunction const&, std::vector> const&, unsigned long, std::vector> const&) @ 0x0000000012da5b15 5. /build/src/Functions/generateSnowflakeID.cpp:172: DB::FunctionGenerateSnowflakeID::getReturnTypeImpl(std::vector> const&) const @ 0x000000000ba4fb67 6. /build/src/Functions/IFunction.cpp:645: DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x0000000012d96b0c 7. /build/src/Functions/IFunction.cpp:577: DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x0000000012d9669c 8. /build/src/Functions/IFunction.cpp:606: DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x0000000012d96edc 9. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3544: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000014033cc9 10. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3838: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000014019a9e 11. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3980: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000014018e31 12. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:4304: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000014042fa7 13. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5605: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000014013749 14. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000140127f9 15. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000014011fce 16. /build/src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000001406ce8a 17. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000014973b42 18. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000001497268d 19. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000014974d24 20. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001492924b 21. /build/src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88641 22. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 23. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 24. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 25. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 26. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 27. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 28. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 29. ? @ 0x00007fbc6213eac3 30. ? @ 0x00007fbc621d0850 2025.07.28 12:03:28.235446 [ 11826 ] {} TCPHandler: Code: 44. DB::Exception: A value of illegal type was provided as 2nd argument 'machine_id' to function 'generateSnowflakeID'. Expected: const UInt*, got: UInt8: In scope SELECT generateSnowflakeID(1, materialize(2)). (ILLEGAL_COLUMN), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: 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&&) @ 0x0000000012da74d9 4. /build/src/Functions/FunctionHelpers.cpp:130: DB::(anonymous namespace)::validateArgumentsImpl(DB::IFunction const&, std::vector> const&, unsigned long, std::vector> const&) @ 0x0000000012da5b15 5. /build/src/Functions/generateSnowflakeID.cpp:172: DB::FunctionGenerateSnowflakeID::getReturnTypeImpl(std::vector> const&) const @ 0x000000000ba4fb67 6. /build/src/Functions/IFunction.cpp:645: DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x0000000012d96b0c 7. /build/src/Functions/IFunction.cpp:577: DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x0000000012d9669c 8. /build/src/Functions/IFunction.cpp:606: DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x0000000012d96edc 9. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3544: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000014033cc9 10. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3838: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000014019a9e 11. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3980: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000014018e31 12. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:4304: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000014042fa7 13. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5605: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000014013749 14. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000140127f9 15. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000014011fce 16. /build/src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000001406ce8a 17. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000014973b42 18. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000001497268d 19. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000014974d24 20. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001492924b 21. /build/src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88641 22. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 23. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 24. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 25. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 26. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 27. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 28. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 29. ? @ 0x00007fbc6213eac3 30. ? @ 0x00007fbc621d0850 2025.07.28 12:03:29.025690 [ 3968 ] {} test_13.rmt2 (7f9b740d-015c-470e-8cc6-8ba33be0dc63): auto DB::StorageReplicatedMergeTree::processQueueEntry(ReplicatedMergeTreeQueue::SelectedEntryPtr)::(anonymous class)::operator()(LogEntryPtr &) const: Code: 86. DB::HTTPException: Received error from remote server http://146b4357c08d:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Ftest%2F01165%2Ftest_13%2Frmt%2Freplicas%2F1&part=20250728_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.6.10636.altinitytest (altinity build)) '. (RECEIVED_ERROR_FROM_REMOTE_IO_SERVER), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.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 const&, int&&, String const&, unsigned long&&, String const&) @ 0x000000000feda8d9 4. /build/src/IO/HTTPCommon.cpp:104: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x000000000feda6e2 5. /build/src/IO/HTTPCommon.cpp:93: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x000000000feda537 6. /build/src/IO/ReadWriteBufferFromHTTP.cpp:277: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x000000001184a4c4 7. /build/src/IO/ReadWriteBufferFromHTTP.cpp:285: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x000000001184a615 8. /build/src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x000000001184ae59 9. /build/src/IO/ReadWriteBufferFromHTTP.cpp:472: void std::__function::__policy_invoker::__call_impl[abi:se190107]>(std::__function::__policy_storage const*) @ 0x000000001184cedd 10. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001184858b 11. /build/src/IO/ReadWriteBufferFromHTTP.cpp:465: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x000000001184bf0b 12. /build/src/IO/ReadBuffer.h:60: DB::ReadBuffer::next() @ 0x000000000a148c7b 13. /build/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) @ 0x0000000011849fb2 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]>&)>&, 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&) @ 0x0000000011841980 15. /build/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) @ 0x000000001621208e 16. /build/src/Storages/StorageReplicatedMergeTree.cpp:5228: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl[abi:se190107] const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000015f9a5fe 17. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000015ed8bfd 18. /build/src/Storages/StorageReplicatedMergeTree.cpp:2514: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x0000000015ec9aab 19. /build/src/Storages/StorageReplicatedMergeTree.cpp:2349: DB::StorageReplicatedMergeTree::executeLogEntry(DB::ReplicatedMergeTreeLogEntry&) @ 0x0000000015eba91b 20. /build/src/Storages/StorageReplicatedMergeTree.cpp:3876: bool std::__function::__policy_invoker&)>::__call_impl[abi:se190107])::$_1, bool (std::shared_ptr&)>>(std::__function::__policy_storage const*, std::shared_ptr&) @ 0x0000000015f9837e 21. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000165d6fc3 22. /build/src/Storages/StorageReplicatedMergeTree.cpp:3872: DB::StorageReplicatedMergeTree::processQueueEntry(std::shared_ptr) @ 0x0000000015efc18a 23. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001624c1b2 24. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000162f9c70 25. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x00000000162fa55a 26. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc6653 27. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000000fccc4c3 28. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc3d92 29. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fcca080 30. ? @ 0x00007fbc6213eac3 31. ? @ 0x00007fbc621d0850 (version 25.3.6.10636.altinitytest (altinity build)) 2025.07.28 12:03:30.036274 [ 3963 ] {} test_13.rmt2 (7f9b740d-015c-470e-8cc6-8ba33be0dc63): auto DB::StorageReplicatedMergeTree::processQueueEntry(ReplicatedMergeTreeQueue::SelectedEntryPtr)::(anonymous class)::operator()(LogEntryPtr &) const: Code: 86. DB::HTTPException: Received error from remote server http://146b4357c08d:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Ftest%2F01165%2Ftest_13%2Frmt%2Freplicas%2F1&part=20250728_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.6.10636.altinitytest (altinity build)) '. (RECEIVED_ERROR_FROM_REMOTE_IO_SERVER), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.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 const&, int&&, String const&, unsigned long&&, String const&) @ 0x000000000feda8d9 4. /build/src/IO/HTTPCommon.cpp:104: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x000000000feda6e2 5. /build/src/IO/HTTPCommon.cpp:93: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x000000000feda537 6. /build/src/IO/ReadWriteBufferFromHTTP.cpp:277: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x000000001184a4c4 7. /build/src/IO/ReadWriteBufferFromHTTP.cpp:285: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x000000001184a615 8. /build/src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x000000001184ae59 9. /build/src/IO/ReadWriteBufferFromHTTP.cpp:472: void std::__function::__policy_invoker::__call_impl[abi:se190107]>(std::__function::__policy_storage const*) @ 0x000000001184cedd 10. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001184858b 11. /build/src/IO/ReadWriteBufferFromHTTP.cpp:465: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x000000001184bf0b 12. /build/src/IO/ReadBuffer.h:60: DB::ReadBuffer::next() @ 0x000000000a148c7b 13. /build/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) @ 0x0000000011849fb2 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]>&)>&, 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&) @ 0x0000000011841980 15. /build/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) @ 0x000000001621208e 16. /build/src/Storages/StorageReplicatedMergeTree.cpp:5228: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl[abi:se190107] const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000015f9a5fe 17. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000015ed8bfd 18. /build/src/Storages/StorageReplicatedMergeTree.cpp:2514: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x0000000015ec9aab 19. /build/src/Storages/StorageReplicatedMergeTree.cpp:2349: DB::StorageReplicatedMergeTree::executeLogEntry(DB::ReplicatedMergeTreeLogEntry&) @ 0x0000000015eba91b 20. /build/src/Storages/StorageReplicatedMergeTree.cpp:3876: bool std::__function::__policy_invoker&)>::__call_impl[abi:se190107])::$_1, bool (std::shared_ptr&)>>(std::__function::__policy_storage const*, std::shared_ptr&) @ 0x0000000015f9837e 21. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000165d6fc3 22. /build/src/Storages/StorageReplicatedMergeTree.cpp:3872: DB::StorageReplicatedMergeTree::processQueueEntry(std::shared_ptr) @ 0x0000000015efc18a 23. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001624c1b2 24. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000162f9c70 25. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x00000000162fa55a 26. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc6653 27. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000000fccc4c3 28. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc3d92 29. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fcca080 30. ? @ 0x00007fbc6213eac3 31. ? @ 0x00007fbc621d0850 (version 25.3.6.10636.altinitytest (altinity build)) 2025.07.28 12:03:30.651436 [ 3971 ] {} test_13.rmt2 (7f9b740d-015c-470e-8cc6-8ba33be0dc63): auto DB::StorageReplicatedMergeTree::processQueueEntry(ReplicatedMergeTreeQueue::SelectedEntryPtr)::(anonymous class)::operator()(LogEntryPtr &) const: Code: 86. DB::HTTPException: Received error from remote server http://146b4357c08d:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Ftest%2F01165%2Ftest_13%2Frmt%2Freplicas%2F1&part=20250728_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.6.10636.altinitytest (altinity build)) '. (RECEIVED_ERROR_FROM_REMOTE_IO_SERVER), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.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 const&, int&&, String const&, unsigned long&&, String const&) @ 0x000000000feda8d9 4. /build/src/IO/HTTPCommon.cpp:104: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x000000000feda6e2 5. /build/src/IO/HTTPCommon.cpp:93: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x000000000feda537 6. /build/src/IO/ReadWriteBufferFromHTTP.cpp:277: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x000000001184a4c4 7. /build/src/IO/ReadWriteBufferFromHTTP.cpp:285: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x000000001184a615 8. /build/src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x000000001184ae59 9. /build/src/IO/ReadWriteBufferFromHTTP.cpp:472: void std::__function::__policy_invoker::__call_impl[abi:se190107]>(std::__function::__policy_storage const*) @ 0x000000001184cedd 10. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001184858b 11. /build/src/IO/ReadWriteBufferFromHTTP.cpp:465: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x000000001184bf0b 12. /build/src/IO/ReadBuffer.h:60: DB::ReadBuffer::next() @ 0x000000000a148c7b 13. /build/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) @ 0x0000000011849fb2 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]>&)>&, 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&) @ 0x0000000011841980 15. /build/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) @ 0x000000001621208e 16. /build/src/Storages/StorageReplicatedMergeTree.cpp:5228: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl[abi:se190107] const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000015f9a5fe 17. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000015ed8bfd 18. /build/src/Storages/StorageReplicatedMergeTree.cpp:2514: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x0000000015ec9aab 19. /build/src/Storages/StorageReplicatedMergeTree.cpp:2349: DB::StorageReplicatedMergeTree::executeLogEntry(DB::ReplicatedMergeTreeLogEntry&) @ 0x0000000015eba91b 20. /build/src/Storages/StorageReplicatedMergeTree.cpp:3876: bool std::__function::__policy_invoker&)>::__call_impl[abi:se190107])::$_1, bool (std::shared_ptr&)>>(std::__function::__policy_storage const*, std::shared_ptr&) @ 0x0000000015f9837e 21. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000165d6fc3 22. /build/src/Storages/StorageReplicatedMergeTree.cpp:3872: DB::StorageReplicatedMergeTree::processQueueEntry(std::shared_ptr) @ 0x0000000015efc18a 23. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001624c1b2 24. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000162f9c70 25. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x00000000162fa55a 26. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc6653 27. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000000fccc4c3 28. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc3d92 29. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fcca080 30. ? @ 0x00007fbc6213eac3 31. ? @ 0x00007fbc621d0850 (version 25.3.6.10636.altinitytest (altinity build)) 2025.07.28 12:03:30.837066 [ 3960 ] {} test_13.rmt2 (7f9b740d-015c-470e-8cc6-8ba33be0dc63): auto DB::StorageReplicatedMergeTree::processQueueEntry(ReplicatedMergeTreeQueue::SelectedEntryPtr)::(anonymous class)::operator()(LogEntryPtr &) const: Code: 86. DB::HTTPException: Received error from remote server http://146b4357c08d:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Ftest%2F01165%2Ftest_13%2Frmt%2Freplicas%2F1&part=20250728_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.6.10636.altinitytest (altinity build)) '. (RECEIVED_ERROR_FROM_REMOTE_IO_SERVER), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.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 const&, int&&, String const&, unsigned long&&, String const&) @ 0x000000000feda8d9 4. /build/src/IO/HTTPCommon.cpp:104: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x000000000feda6e2 5. /build/src/IO/HTTPCommon.cpp:93: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x000000000feda537 6. /build/src/IO/ReadWriteBufferFromHTTP.cpp:277: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x000000001184a4c4 7. /build/src/IO/ReadWriteBufferFromHTTP.cpp:285: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x000000001184a615 8. /build/src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x000000001184ae59 9. /build/src/IO/ReadWriteBufferFromHTTP.cpp:472: void std::__function::__policy_invoker::__call_impl[abi:se190107]>(std::__function::__policy_storage const*) @ 0x000000001184cedd 10. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001184858b 11. /build/src/IO/ReadWriteBufferFromHTTP.cpp:465: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x000000001184bf0b 12. /build/src/IO/ReadBuffer.h:60: DB::ReadBuffer::next() @ 0x000000000a148c7b 13. /build/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) @ 0x0000000011849fb2 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]>&)>&, 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&) @ 0x0000000011841980 15. /build/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) @ 0x000000001621208e 16. /build/src/Storages/StorageReplicatedMergeTree.cpp:5228: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl[abi:se190107] const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000015f9a5fe 17. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000015ed8bfd 18. /build/src/Storages/StorageReplicatedMergeTree.cpp:2514: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x0000000015ec9aab 19. /build/src/Storages/StorageReplicatedMergeTree.cpp:2349: DB::StorageReplicatedMergeTree::executeLogEntry(DB::ReplicatedMergeTreeLogEntry&) @ 0x0000000015eba91b 20. /build/src/Storages/StorageReplicatedMergeTree.cpp:3876: bool std::__function::__policy_invoker&)>::__call_impl[abi:se190107])::$_1, bool (std::shared_ptr&)>>(std::__function::__policy_storage const*, std::shared_ptr&) @ 0x0000000015f9837e 21. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000165d6fc3 22. /build/src/Storages/StorageReplicatedMergeTree.cpp:3872: DB::StorageReplicatedMergeTree::processQueueEntry(std::shared_ptr) @ 0x0000000015efc18a 23. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001624c1b2 24. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000162f9c70 25. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x00000000162fa55a 26. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc6653 27. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000000fccc4c3 28. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc3d92 29. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fcca080 30. ? @ 0x00007fbc6213eac3 31. ? @ 0x00007fbc621d0850 (version 25.3.6.10636.altinitytest (altinity build)) 2025.07.28 12:03:31.610653 [ 4900 ] {} 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. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception>&, String>(int, FormatStringHelperImpl>&>::type, std::type_identity::type>, std::basic_string_view>&, String&&) @ 0x000000001385a5eb 4. /build/src/Access/SettingsConstraints.cpp:376: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000013859b18 5. /build/src/Access/SettingsConstraints.cpp:300: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000013858faf 6. /build/src/Access/SettingsConstraints.cpp:209: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000013859223 7. /build/src/Interpreters/Context.cpp:2690: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000014436134 8. /build/src/Interpreters/Context.cpp:2729: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x000000001443662b 9. /build/src/Server/HTTPHandler.cpp:457: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000001686d165 10. /build/src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x0000000016870807 11. /build/src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x0000000016907e99 12. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 13. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 14. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 15. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 16. ? @ 0x00007fbc6213eac3 17. ? @ 0x00007fbc621d0850 (version 25.3.6.10636.altinitytest (altinity build)) 2025.07.28 12:03:31.902878 [ 3965 ] {} test_13.rmt2 (7f9b740d-015c-470e-8cc6-8ba33be0dc63): auto DB::StorageReplicatedMergeTree::processQueueEntry(ReplicatedMergeTreeQueue::SelectedEntryPtr)::(anonymous class)::operator()(LogEntryPtr &) const: Code: 86. DB::HTTPException: Received error from remote server http://146b4357c08d:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Ftest%2F01165%2Ftest_13%2Frmt%2Freplicas%2F1&part=20250728_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.6.10636.altinitytest (altinity build)) '. (RECEIVED_ERROR_FROM_REMOTE_IO_SERVER), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.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 const&, int&&, String const&, unsigned long&&, String const&) @ 0x000000000feda8d9 4. /build/src/IO/HTTPCommon.cpp:104: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x000000000feda6e2 5. /build/src/IO/HTTPCommon.cpp:93: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x000000000feda537 6. /build/src/IO/ReadWriteBufferFromHTTP.cpp:277: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x000000001184a4c4 7. /build/src/IO/ReadWriteBufferFromHTTP.cpp:285: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x000000001184a615 8. /build/src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x000000001184ae59 9. /build/src/IO/ReadWriteBufferFromHTTP.cpp:472: void std::__function::__policy_invoker::__call_impl[abi:se190107]>(std::__function::__policy_storage const*) @ 0x000000001184cedd 10. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001184858b 11. /build/src/IO/ReadWriteBufferFromHTTP.cpp:465: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x000000001184bf0b 12. /build/src/IO/ReadBuffer.h:60: DB::ReadBuffer::next() @ 0x000000000a148c7b 13. /build/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) @ 0x0000000011849fb2 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]>&)>&, 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&) @ 0x0000000011841980 15. /build/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) @ 0x000000001621208e 16. /build/src/Storages/StorageReplicatedMergeTree.cpp:5228: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl[abi:se190107] const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000015f9a5fe 17. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000015ed8bfd 18. /build/src/Storages/StorageReplicatedMergeTree.cpp:2514: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x0000000015ec9aab 19. /build/src/Storages/StorageReplicatedMergeTree.cpp:2349: DB::StorageReplicatedMergeTree::executeLogEntry(DB::ReplicatedMergeTreeLogEntry&) @ 0x0000000015eba91b 20. /build/src/Storages/StorageReplicatedMergeTree.cpp:3876: bool std::__function::__policy_invoker&)>::__call_impl[abi:se190107])::$_1, bool (std::shared_ptr&)>>(std::__function::__policy_storage const*, std::shared_ptr&) @ 0x0000000015f9837e 21. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000165d6fc3 22. /build/src/Storages/StorageReplicatedMergeTree.cpp:3872: DB::StorageReplicatedMergeTree::processQueueEntry(std::shared_ptr) @ 0x0000000015efc18a 23. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001624c1b2 24. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000162f9c70 25. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x00000000162fa55a 26. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc6653 27. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000000fccc4c3 28. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc3d92 29. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fcca080 30. ? @ 0x00007fbc6213eac3 31. ? @ 0x00007fbc621d0850 (version 25.3.6.10636.altinitytest (altinity build)) 2025.07.28 12:03:32.170688 [ 7625 ] {84738e95-ecad-4697-b269-f2cbe9163569} executeQuery: Code: 62. DB::Exception: Cannot TRUNCATE dictionary. (SYNTAX_ERROR) (version 25.3.6.10636.altinitytest (altinity build)) (from [::1]:47808) (comment: 01764_table_function_dictionary.sql) (query 8, line 24) (in query: DROP DICTIONARY table_function_dictionary_test_dictionary;), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000000a074fcb 4. /build/src/Interpreters/InterpreterDropQuery.cpp:266: DB::InterpreterDropQuery::executeToTableImpl(std::shared_ptr const&, DB::ASTDropQuery&, std::shared_ptr&, StrongTypedef, DB::UUIDTag>&) @ 0x0000000014915b7b 5. /build/src/Interpreters/InterpreterDropQuery.cpp:118: DB::InterpreterDropQuery::executeToTable(DB::ASTDropQuery&) @ 0x00000000149137b4 6. /build/src/Interpreters/InterpreterDropQuery.cpp:91: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000014912f07 7. /build/src/Interpreters/InterpreterDropQuery.cpp:72: DB::InterpreterDropQuery::execute() @ 0x0000000014912b65 8. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88dc9 9. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 10. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 11. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 12. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 13. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 14. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 15. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 16. ? @ 0x00007fbc6213eac3 17. ? @ 0x00007fbc621d0850 2025.07.28 12:03:32.182236 [ 7625 ] {} TCPHandler: Code: 62. DB::Exception: Cannot TRUNCATE dictionary. (SYNTAX_ERROR), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000000a074fcb 4. /build/src/Interpreters/InterpreterDropQuery.cpp:266: DB::InterpreterDropQuery::executeToTableImpl(std::shared_ptr const&, DB::ASTDropQuery&, std::shared_ptr&, StrongTypedef, DB::UUIDTag>&) @ 0x0000000014915b7b 5. /build/src/Interpreters/InterpreterDropQuery.cpp:118: DB::InterpreterDropQuery::executeToTable(DB::ASTDropQuery&) @ 0x00000000149137b4 6. /build/src/Interpreters/InterpreterDropQuery.cpp:91: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000014912f07 7. /build/src/Interpreters/InterpreterDropQuery.cpp:72: DB::InterpreterDropQuery::execute() @ 0x0000000014912b65 8. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88dc9 9. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 10. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 11. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 12. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 13. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 14. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 15. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 16. ? @ 0x00007fbc6213eac3 17. ? @ 0x00007fbc621d0850 2025.07.28 12:03:32.244362 [ 4900 ] {6193f951-4ea6-429e-a726-e5f7a3b8f6f6} executeQuery: Code: 62. DB::Exception: Cannot TRUNCATE dictionary. (SYNTAX_ERROR) (version 25.3.6.10636.altinitytest (altinity build)) (from [::1]:51536) (comment: 01764_table_function_dictionary.sql) (in query: DROP DATABASE IF EXISTS test_bvs99rmc SYNC ), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000000a074fcb 4. /build/src/Interpreters/InterpreterDropQuery.cpp:266: DB::InterpreterDropQuery::executeToTableImpl(std::shared_ptr const&, DB::ASTDropQuery&, std::shared_ptr&, StrongTypedef, DB::UUIDTag>&) @ 0x0000000014915b7b 5. /build/src/Interpreters/InterpreterDropQuery.cpp:461: DB::InterpreterDropQuery::executeToDatabaseImpl(DB::ASTDropQuery const&, std::shared_ptr&, std::vector, DB::UUIDTag>, std::allocator, DB::UUIDTag>>>&) @ 0x0000000014917707 6. /build/src/Interpreters/InterpreterDropQuery.cpp:363: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x0000000014913988 7. /build/src/Interpreters/InterpreterDropQuery.cpp:99: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000014913142 8. /build/src/Interpreters/InterpreterDropQuery.cpp:72: DB::InterpreterDropQuery::execute() @ 0x0000000014912b65 9. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88dc9 10. /build/src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x0000000014c8ca7b 11. /build/src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000001686da12 12. /build/src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x0000000016870807 13. /build/src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x0000000016907e99 14. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 15. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 16. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 17. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 18. ? @ 0x00007fbc6213eac3 19. ? @ 0x00007fbc621d0850 2025.07.28 12:03:32.248088 [ 4900 ] {6193f951-4ea6-429e-a726-e5f7a3b8f6f6} DynamicQueryHandler: Code: 62. DB::Exception: Cannot TRUNCATE dictionary. (SYNTAX_ERROR), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000000a074fcb 4. /build/src/Interpreters/InterpreterDropQuery.cpp:266: DB::InterpreterDropQuery::executeToTableImpl(std::shared_ptr const&, DB::ASTDropQuery&, std::shared_ptr&, StrongTypedef, DB::UUIDTag>&) @ 0x0000000014915b7b 5. /build/src/Interpreters/InterpreterDropQuery.cpp:461: DB::InterpreterDropQuery::executeToDatabaseImpl(DB::ASTDropQuery const&, std::shared_ptr&, std::vector, DB::UUIDTag>, std::allocator, DB::UUIDTag>>>&) @ 0x0000000014917707 6. /build/src/Interpreters/InterpreterDropQuery.cpp:363: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x0000000014913988 7. /build/src/Interpreters/InterpreterDropQuery.cpp:99: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x0000000014913142 8. /build/src/Interpreters/InterpreterDropQuery.cpp:72: DB::InterpreterDropQuery::execute() @ 0x0000000014912b65 9. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88dc9 10. /build/src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x0000000014c8ca7b 11. /build/src/Server/HTTPHandler.cpp:594: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000001686da12 12. /build/src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x0000000016870807 13. /build/src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x0000000016907e99 14. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 15. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 16. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 17. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 18. ? @ 0x00007fbc6213eac3 19. ? @ 0x00007fbc621d0850 (version 25.3.6.10636.altinitytest (altinity build)) 2025.07.28 12:03:32.281387 [ 5747 ] {28edfd35-0231-48b4-82a2-044789264e93} executeQuery: Code: 241. DB::Exception: Query memory limit exceeded: would use 1.02 GiB (attempt to allocate chunk of 128.00 MiB bytes), maximum: 953.67 MiB.: While executing AggregatingTransform. (MEMORY_LIMIT_EXCEEDED) (version 25.3.6.10636.altinitytest (altinity build)) (from [::ffff:127.0.0.1]:33376) (comment: 01514_distributed_cancel_query_on_error.sh) (query 1, line 1) (in query: SELECT groupArray(repeat('a', if(shardNum() = 2, 100000, 1))) AS `groupArray(repeat('a', if(equals(_shard_num, 2), 100000, 1)))`, `__table1`.`number` % 100000 AS `k` FROM `system`.`numbers` AS `__table1` GROUP BY `__table1`.`number` % 100000 LIMIT _CAST(10000000, 'UInt64')), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000000fc1ab36 4. /build/src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000000fc196ef 5. /build/src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000000fc19293 6. /build/src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000000fb80c54 7. /build/src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000000fb7f3c4 8. /build/src/Common/Arena.h:76: DB::Arena::addMemoryChunk(unsigned long) @ 0x000000000aabf255 9. /build/src/Common/Arena.h:196: DB::(anonymous namespace)::GroupArrayNodeString::allocate(DB::IColumn const&, unsigned long, DB::Arena*) @ 0x000000001018a2ff 10. /build/src/AggregateFunctions/AggregateFunctionGroupArray.cpp:554: DB::IAggregateFunctionHelper>>::addBatch(unsigned long, unsigned long, char**, unsigned long, DB::IColumn const**, DB::Arena*, long) const @ 0x00000000101aecb5 11. /build/src/Interpreters/Aggregator.cpp:1338: DB::Aggregator::executeAggregateInstructions(DB::Arena*, unsigned long, unsigned long, DB::Aggregator::AggregateFunctionInstruction*, std::unique_ptr> const&, unsigned long, bool, bool, bool) const @ 0x0000000014591614 12. /build/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 @ 0x00000000146bf12d 13. /build/src/Interpreters/Aggregator.cpp:0: 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 @ 0x00000000146bc9c2 14. /build/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 @ 0x00000000145fd7cf 15. /build/src/Interpreters/Aggregator.cpp:922: DB::Aggregator::executeImpl(DB::AggregatedDataVariants&, unsigned long, unsigned long, std::vector>&, DB::Aggregator::AggregateFunctionInstruction*, bool, bool, char*) const @ 0x000000001458fd39 16. /build/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 @ 0x0000000014593b80 17. /build/src/Processors/Transforms/AggregatingTransform.cpp:690: DB::AggregatingTransform::consume(DB::Chunk) @ 0x0000000016bf205c 18. /build/src/Processors/Transforms/AggregatingTransform.cpp:648: DB::AggregatingTransform::work() @ 0x0000000016bef6c6 19. /build/src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x00000000169bd00f 20. /build/src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x00000000169b2105 21. /build/src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeSingleThread(unsigned long) @ 0x00000000169b23be 22. /build/src/Processors/Executors/PipelineExecutor.cpp:454: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x00000000169b0be7 23. /build/src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x00000000169b03f4 24. /build/src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:se190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169bfeab 25. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc3d92 26. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fcca080 27. ? @ 0x00007fbc6213eac3 28. ? @ 0x00007fbc621d0850 2025.07.28 12:03:32.325579 [ 5747 ] {} TCPHandler: Code: 241. DB::Exception: Query memory limit exceeded: would use 1.02 GiB (attempt to allocate chunk of 128.00 MiB bytes), maximum: 953.67 MiB.: While executing AggregatingTransform. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000000fc1ab36 4. /build/src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000000fc196ef 5. /build/src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000000fc19293 6. /build/src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000000fb80c54 7. /build/src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000000fb7f3c4 8. /build/src/Common/Arena.h:76: DB::Arena::addMemoryChunk(unsigned long) @ 0x000000000aabf255 9. /build/src/Common/Arena.h:196: DB::(anonymous namespace)::GroupArrayNodeString::allocate(DB::IColumn const&, unsigned long, DB::Arena*) @ 0x000000001018a2ff 10. /build/src/AggregateFunctions/AggregateFunctionGroupArray.cpp:554: DB::IAggregateFunctionHelper>>::addBatch(unsigned long, unsigned long, char**, unsigned long, DB::IColumn const**, DB::Arena*, long) const @ 0x00000000101aecb5 11. /build/src/Interpreters/Aggregator.cpp:1338: DB::Aggregator::executeAggregateInstructions(DB::Arena*, unsigned long, unsigned long, DB::Aggregator::AggregateFunctionInstruction*, std::unique_ptr> const&, unsigned long, bool, bool, bool) const @ 0x0000000014591614 12. /build/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 @ 0x00000000146bf12d 13. /build/src/Interpreters/Aggregator.cpp:0: 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 @ 0x00000000146bc9c2 14. /build/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 @ 0x00000000145fd7cf 15. /build/src/Interpreters/Aggregator.cpp:922: DB::Aggregator::executeImpl(DB::AggregatedDataVariants&, unsigned long, unsigned long, std::vector>&, DB::Aggregator::AggregateFunctionInstruction*, bool, bool, char*) const @ 0x000000001458fd39 16. /build/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 @ 0x0000000014593b80 17. /build/src/Processors/Transforms/AggregatingTransform.cpp:690: DB::AggregatingTransform::consume(DB::Chunk) @ 0x0000000016bf205c 18. /build/src/Processors/Transforms/AggregatingTransform.cpp:648: DB::AggregatingTransform::work() @ 0x0000000016bef6c6 19. /build/src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x00000000169bd00f 20. /build/src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x00000000169b2105 21. /build/src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeSingleThread(unsigned long) @ 0x00000000169b23be 22. /build/src/Processors/Executors/PipelineExecutor.cpp:454: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x00000000169b0be7 23. /build/src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x00000000169b03f4 24. /build/src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:se190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169bfeab 25. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc3d92 26. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fcca080 27. ? @ 0x00007fbc6213eac3 28. ? @ 0x00007fbc621d0850 Job's origin stack trace: 0. /build/src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000000fc33b84 1. /build/src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000000fcc2ea7 2. /build/src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fcc535c 3. /build/src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000000fcc584d 4. /build/src/Common/ThreadPool.h:279: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x00000000169bf193 5. /build/src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x00000000169bf518 6. /build/src/Server/TCPHandler.cpp:1237: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x00000000168f1525 7. /build/src/Server/TCPHandler.cpp:678: DB::TCPHandler::runImpl() @ 0x00000000168e68e5 8. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 9. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 10. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 11. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 12. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 13. ? @ 0x00007fbc6213eac3 14. ? @ 0x00007fbc621d0850 2025.07.28 12:03:32.350552 [ 11826 ] {1d8bcd0b-bdb1-487d-bcaa-e08c50e63272} executeQuery: Code: 241. DB::Exception: Received from 127.3:9000. DB::Exception: Query memory limit exceeded: would use 1.02 GiB (attempt to allocate chunk of 128.00 MiB bytes), maximum: 953.67 MiB.: While executing AggregatingTransform. Stack trace: 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000000fc1ab36 4. /build/src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000000fc196ef 5. /build/src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000000fc19293 6. /build/src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000000fb80c54 7. /build/src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000000fb7f3c4 8. /build/src/Common/Arena.h:76: DB::Arena::addMemoryChunk(unsigned long) @ 0x000000000aabf255 9. /build/src/Common/Arena.h:196: DB::(anonymous namespace)::GroupArrayNodeString::allocate(DB::IColumn const&, unsigned long, DB::Arena*) @ 0x000000001018a2ff 10. /build/src/AggregateFunctions/AggregateFunctionGroupArray.cpp:554: DB::IAggregateFunctionHelper>>::addBatch(unsigned long, unsigned long, char**, unsigned long, DB::IColumn const**, DB::Arena*, long) const @ 0x00000000101aecb5 11. /build/src/Interpreters/Aggregator.cpp:1338: DB::Aggregator::executeAggregateInstructions(DB::Arena*, unsigned long, unsigned long, DB::Aggregator::AggregateFunctionInstruction*, std::unique_ptr> const&, unsigned long, bool, bool, bool) const @ 0x0000000014591614 12. /build/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 @ 0x00000000146bf12d 13. /build/src/Interpreters/Aggregator.cpp:0: 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 @ 0x00000000146bc9c2 14. /build/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 @ 0x00000000145fd7cf 15. /build/src/Interpreters/Aggregator.cpp:922: DB::Aggregator::executeImpl(DB::AggregatedDataVariants&, unsigned long, unsigned long, std::vector>&, DB::Aggregator::AggregateFunctionInstruction*, bool, bool, char*) const @ 0x000000001458fd39 16. /build/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 @ 0x0000000014593b80 17. /build/src/Processors/Transforms/AggregatingTransform.cpp:690: DB::AggregatingTransform::consume(DB::Chunk) @ 0x0000000016bf205c 18. /build/src/Processors/Transforms/AggregatingTransform.cpp:648: DB::AggregatingTransform::work() @ 0x0000000016bef6c6 19. /build/src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x00000000169bd00f 20. /build/src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x00000000169b2105 21. /build/src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeSingleThread(unsigned long) @ 0x00000000169b23be 22. /build/src/Processors/Executors/PipelineExecutor.cpp:454: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x00000000169b0be7 23. /build/src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x00000000169b03f4 24. /build/src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:se190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169bfeab 25. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc3d92 26. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fcca080 27. ? @ 0x00007fbc6213eac3 28. ? @ 0x00007fbc621d0850 Job's origin stack trace: 0. /build/src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000000fc33b84 1. /build/src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000000fcc2ea7 2. /build/src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fcc535c 3. /build/src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000000fcc584d 4. /build/src/Common/ThreadPool.h:279: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x00000000169bf193 5. /build/src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x00000000169bf518 6. /build/src/Server/TCPHandler.cpp:1237: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x00000000168f1525 7. /build/src/Server/TCPHandler.cpp:678: DB::TCPHandler::runImpl() @ 0x00000000168e68e5 8. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 9. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 10. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 11. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 12. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 13. ? @ 0x00007fbc6213eac3 14. ? @ 0x00007fbc621d0850 : While executing Remote. (MEMORY_LIMIT_EXCEEDED) (version 25.3.6.10636.altinitytest (altinity build)) (from [::1]:39128) (comment: 01514_distributed_cancel_query_on_error.sh) (query 1, line 1) (in query: SELECT groupArray(repeat('a', if(_shard_num == 2, 100000, 1))), number%100000 k from remote('127.{2,3}', system.numbers) GROUP BY k LIMIT 10e6), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:111: DB::readException(DB::ReadBuffer&, String const&, bool) @ 0x000000000fc6e157 3. /build/src/Client/Connection.cpp:1445: DB::Connection::receiveException() const @ 0x00000000167d4127 4. /build/src/Client/Connection.cpp:1274: DB::Connection::receivePacket() @ 0x00000000167db312 5. /build/src/Client/PacketReceiver.cpp:66: DB::PacketReceiver::Task::run(std::function, std::function) @ 0x0000000016819393 6. /build/src/Common/AsyncTaskExecutor.cpp:89: DB::AsyncTaskExecutor::Routine::operator()(std::function) @ 0x0000000013bd1892 7. /build/src/Common/Fiber.h:76: boost::context::detail::fiber_record>::run(void*) @ 0x0000000013bd16fa 8. /build/contrib/boost/boost/context/fiber_fcontext.hpp:97: void boost::context::detail::fiber_entry>>(boost::context::detail::transfer_t) @ 0x0000000013bd1621 2025.07.28 12:03:32.365907 [ 11826 ] {} TCPHandler: Code: 241. DB::Exception: Received from 127.3:9000. DB::Exception: Query memory limit exceeded: would use 1.02 GiB (attempt to allocate chunk of 128.00 MiB bytes), maximum: 953.67 MiB.: While executing AggregatingTransform. Stack trace: 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception>>(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity>>::type>, char const*&&, char const*&&, String&&, String&&, String&&, String&&, String&&, char const*&&, std::basic_string_view>&&) @ 0x000000000fc1ab36 4. /build/src/Common/MemoryTracker.cpp:351: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000000fc196ef 5. /build/src/Common/MemoryTracker.cpp:413: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000000fc19293 6. /build/src/Common/CurrentMemoryTracker.cpp:80: CurrentMemoryTracker::allocImpl(long, bool) @ 0x000000000fb80c54 7. /build/src/Common/Allocator.cpp:149: Allocator::alloc(unsigned long, unsigned long) @ 0x000000000fb7f3c4 8. /build/src/Common/Arena.h:76: DB::Arena::addMemoryChunk(unsigned long) @ 0x000000000aabf255 9. /build/src/Common/Arena.h:196: DB::(anonymous namespace)::GroupArrayNodeString::allocate(DB::IColumn const&, unsigned long, DB::Arena*) @ 0x000000001018a2ff 10. /build/src/AggregateFunctions/AggregateFunctionGroupArray.cpp:554: DB::IAggregateFunctionHelper>>::addBatch(unsigned long, unsigned long, char**, unsigned long, DB::IColumn const**, DB::Arena*, long) const @ 0x00000000101aecb5 11. /build/src/Interpreters/Aggregator.cpp:1338: DB::Aggregator::executeAggregateInstructions(DB::Arena*, unsigned long, unsigned long, DB::Aggregator::AggregateFunctionInstruction*, std::unique_ptr> const&, unsigned long, bool, bool, bool) const @ 0x0000000014591614 12. /build/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 @ 0x00000000146bf12d 13. /build/src/Interpreters/Aggregator.cpp:0: 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 @ 0x00000000146bc9c2 14. /build/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 @ 0x00000000145fd7cf 15. /build/src/Interpreters/Aggregator.cpp:922: DB::Aggregator::executeImpl(DB::AggregatedDataVariants&, unsigned long, unsigned long, std::vector>&, DB::Aggregator::AggregateFunctionInstruction*, bool, bool, char*) const @ 0x000000001458fd39 16. /build/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 @ 0x0000000014593b80 17. /build/src/Processors/Transforms/AggregatingTransform.cpp:690: DB::AggregatingTransform::consume(DB::Chunk) @ 0x0000000016bf205c 18. /build/src/Processors/Transforms/AggregatingTransform.cpp:648: DB::AggregatingTransform::work() @ 0x0000000016bef6c6 19. /build/src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x00000000169bd00f 20. /build/src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x00000000169b2105 21. /build/src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeSingleThread(unsigned long) @ 0x00000000169b23be 22. /build/src/Processors/Executors/PipelineExecutor.cpp:454: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x00000000169b0be7 23. /build/src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x00000000169b03f4 24. /build/src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:se190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169bfeab 25. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc3d92 26. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fcca080 27. ? @ 0x00007fbc6213eac3 28. ? @ 0x00007fbc621d0850 Job's origin stack trace: 0. /build/src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000000fc33b84 1. /build/src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000000fcc2ea7 2. /build/src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fcc535c 3. /build/src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000000fcc584d 4. /build/src/Common/ThreadPool.h:279: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x00000000169bf193 5. /build/src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x00000000169bf518 6. /build/src/Server/TCPHandler.cpp:1237: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x00000000168f1525 7. /build/src/Server/TCPHandler.cpp:678: DB::TCPHandler::runImpl() @ 0x00000000168e68e5 8. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 9. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 10. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 11. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 12. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 13. ? @ 0x00007fbc6213eac3 14. ? @ 0x00007fbc621d0850 : While executing Remote. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:111: DB::readException(DB::ReadBuffer&, String const&, bool) @ 0x000000000fc6e157 3. /build/src/Client/Connection.cpp:1445: DB::Connection::receiveException() const @ 0x00000000167d4127 4. /build/src/Client/Connection.cpp:1274: DB::Connection::receivePacket() @ 0x00000000167db312 5. /build/src/Client/PacketReceiver.cpp:66: DB::PacketReceiver::Task::run(std::function, std::function) @ 0x0000000016819393 6. /build/src/Common/AsyncTaskExecutor.cpp:89: DB::AsyncTaskExecutor::Routine::operator()(std::function) @ 0x0000000013bd1892 7. /build/src/Common/Fiber.h:76: boost::context::detail::fiber_record>::run(void*) @ 0x0000000013bd16fa 8. /build/contrib/boost/boost/context/fiber_fcontext.hpp:97: void boost::context::detail::fiber_entry>>(boost::context::detail::transfer_t) @ 0x0000000013bd1621 Job's origin stack trace: 0. /build/src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000000fc33b84 1. /build/src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000000fcc2ea7 2. /build/src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fcc535c 3. /build/src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000000fcc584d 4. /build/src/Common/ThreadPool.h:279: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x00000000169bf193 5. /build/src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x00000000169bf518 6. /build/src/Server/TCPHandler.cpp:1237: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x00000000168f1525 7. /build/src/Server/TCPHandler.cpp:678: DB::TCPHandler::runImpl() @ 0x00000000168e68e5 8. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 9. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 10. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 11. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 12. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 13. ? @ 0x00007fbc6213eac3 14. ? @ 0x00007fbc621d0850 2025.07.28 12:03:32.482455 [ 63425 ] {5b9462f8-9f76-42d7-8b1e-a45d1730dc2f} 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]:46040). (NETWORK_ERROR), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::NetException::NetException(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&) @ 0x000000000fd50fb5 3. /build/src/IO/WriteBufferFromPocoSocket.cpp:160: DB::WriteBufferFromPocoSocket::nextImpl() @ 0x000000000fd523f1 4. /build/src/IO/WriteBuffer.h:53: DB::WriteBuffer::next() @ 0x000000000a0755be 5. /build/src/Server/TCPHandler.cpp:824: DB::TCPHandler::runImpl() @ 0x00000000168e6c86 6. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 7. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 8. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 9. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 10. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 11. ? @ 0x00007fbc6213eac3 12. ? @ 0x00007fbc621d0850 (version 25.3.6.10636.altinitytest (altinity build)) 2025.07.28 12:03:32.791307 [ 3974 ] {} test_13.rmt2 (7f9b740d-015c-470e-8cc6-8ba33be0dc63): auto DB::StorageReplicatedMergeTree::processQueueEntry(ReplicatedMergeTreeQueue::SelectedEntryPtr)::(anonymous class)::operator()(LogEntryPtr &) const: Code: 86. DB::HTTPException: Received error from remote server http://146b4357c08d:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Ftest%2F01165%2Ftest_13%2Frmt%2Freplicas%2F1&part=20250728_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.6.10636.altinitytest (altinity build)) '. (RECEIVED_ERROR_FROM_REMOTE_IO_SERVER), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.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 const&, int&&, String const&, unsigned long&&, String const&) @ 0x000000000feda8d9 4. /build/src/IO/HTTPCommon.cpp:104: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x000000000feda6e2 5. /build/src/IO/HTTPCommon.cpp:93: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x000000000feda537 6. /build/src/IO/ReadWriteBufferFromHTTP.cpp:277: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x000000001184a4c4 7. /build/src/IO/ReadWriteBufferFromHTTP.cpp:285: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x000000001184a615 8. /build/src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x000000001184ae59 9. /build/src/IO/ReadWriteBufferFromHTTP.cpp:472: void std::__function::__policy_invoker::__call_impl[abi:se190107]>(std::__function::__policy_storage const*) @ 0x000000001184cedd 10. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001184858b 11. /build/src/IO/ReadWriteBufferFromHTTP.cpp:465: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x000000001184bf0b 12. /build/src/IO/ReadBuffer.h:60: DB::ReadBuffer::next() @ 0x000000000a148c7b 13. /build/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) @ 0x0000000011849fb2 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]>&)>&, 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&) @ 0x0000000011841980 15. /build/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) @ 0x000000001621208e 16. /build/src/Storages/StorageReplicatedMergeTree.cpp:5228: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl[abi:se190107] const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000015f9a5fe 17. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000015ed8bfd 18. /build/src/Storages/StorageReplicatedMergeTree.cpp:2514: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x0000000015ec9aab 19. /build/src/Storages/StorageReplicatedMergeTree.cpp:2349: DB::StorageReplicatedMergeTree::executeLogEntry(DB::ReplicatedMergeTreeLogEntry&) @ 0x0000000015eba91b 20. /build/src/Storages/StorageReplicatedMergeTree.cpp:3876: bool std::__function::__policy_invoker&)>::__call_impl[abi:se190107])::$_1, bool (std::shared_ptr&)>>(std::__function::__policy_storage const*, std::shared_ptr&) @ 0x0000000015f9837e 21. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000165d6fc3 22. /build/src/Storages/StorageReplicatedMergeTree.cpp:3872: DB::StorageReplicatedMergeTree::processQueueEntry(std::shared_ptr) @ 0x0000000015efc18a 23. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001624c1b2 24. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000162f9c70 25. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x00000000162fa55a 26. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc6653 27. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000000fccc4c3 28. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc3d92 29. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fcca080 30. ? @ 0x00007fbc6213eac3 31. ? @ 0x00007fbc621d0850 (version 25.3.6.10636.altinitytest (altinity build)) 2025.07.28 12:03:33.005699 [ 5029 ] {} 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. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x000000000c25bc4b 4. /build/src/Access/SettingsConstraints.cpp:343: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x00000000138596e3 5. /build/src/Access/SettingsConstraints.cpp:300: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000013858faf 6. /build/src/Access/SettingsConstraints.cpp:209: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x00000000138592b8 7. /build/src/Interpreters/Context.cpp:2690: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000014436134 8. /build/src/Interpreters/Context.cpp:2729: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x000000001443662b 9. /build/src/Server/TCPHandler.cpp:2158: DB::TCPHandler::processQuery(std::optional&) @ 0x00000000168f61df 10. /build/src/Server/TCPHandler.cpp:918: DB::TCPHandler::receivePacketsExpectQuery(std::optional&) @ 0x00000000168ef965 11. /build/src/Server/TCPHandler.cpp:491: DB::TCPHandler::runImpl() @ 0x00000000168e5eb4 12. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 13. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 14. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 15. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 16. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 17. ? @ 0x00007fbc6213eac3 18. ? @ 0x00007fbc621d0850 2025.07.28 12:03:33.006475 [ 5029 ] {} 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. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000000a074fcb 4. /build/src/Server/TCPHandler.cpp:897: DB::TCPHandler::receivePacketsExpectQuery(std::optional&) @ 0x00000000168efa89 5. /build/src/Server/TCPHandler.cpp:491: DB::TCPHandler::runImpl() @ 0x00000000168e5eb4 6. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 7. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 8. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 9. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 10. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 11. ? @ 0x00007fbc6213eac3 12. ? @ 0x00007fbc621d0850 2025.07.28 12:03:33.071525 [ 62053 ] {75e67a01-b4bf-43f6-acae-3f194fbbbce0} executeQuery: Code: 57. DB::Exception: Table test_5.test already exists. (TABLE_ALREADY_EXISTS) (version 25.3.6.10636.altinitytest (altinity build)) (from 0.0.0.0:0) (comment: 02025_having_filter_column.sql) (in query: /* ddl_entry=query-0000000205 */ CREATE TABLE test_5.test UUID '0741fcc9-21b9-4ce1-9124-bce828614ddd' (`d` DateTime, `a` String, `b` UInt64) ENGINE = MergeTree PARTITION BY toDate(d) ORDER BY d SETTINGS index_granularity = 52425, min_bytes_for_wide_part = 0, ratio_of_defaults_for_sparse_serialization = 0., replace_long_file_name_to_hash = false, max_file_name_length = 49, min_bytes_for_full_part_storage = 0, compact_parts_max_bytes_to_buffer = 339106911, compact_parts_max_granules_to_buffer = 63, compact_parts_merge_max_bytes_to_prefetch_part = 27403824, merge_max_block_size = 24122, old_parts_lifetime = 480., 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 = 9470899268, index_granularity_bytes = 16871333, use_const_adaptive_granularity = false, enable_index_granularity_compression = false, 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 = true, marks_compress_block_size = 37221, primary_key_compress_block_size = 84184, 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. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000a06a8eb 4. /build/src/Interpreters/InterpreterCreateQuery.cpp:1824: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x0000000014901d53 5. /build/src/Interpreters/InterpreterCreateQuery.cpp:1743: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000148f9aa9 6. /build/src/Interpreters/InterpreterCreateQuery.cpp:2352: DB::InterpreterCreateQuery::execute() @ 0x0000000014905a41 7. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88dc9 8. /build/src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x0000000014c8ca7b 9. /build/src/Interpreters/DDLWorker.cpp:510: DB::DDLWorker::tryExecuteQuery(DB::DDLTaskBase&, std::shared_ptr const&, bool) @ 0x00000000144dab9e 10. /build/src/Interpreters/DDLWorker.cpp:675: DB::DDLWorker::processTask(DB::DDLTaskBase&, std::shared_ptr const&, bool) @ 0x00000000144d8ffe 11. /build/src/Databases/DatabaseReplicatedWorker.cpp:372: DB::DatabaseReplicatedDDLWorker::tryEnqueueAndExecuteEntry(DB::DDLLogEntry&, std::shared_ptr, bool) @ 0x0000000013dc29ab 12. /build/src/Databases/DatabaseReplicated.cpp:1139: DB::DatabaseReplicated::tryEnqueueReplicatedDDL(std::shared_ptr const&, std::shared_ptr, DB::QueryFlags) @ 0x0000000013d9f73c 13. /build/src/Interpreters/InterpreterCreateQuery.cpp:1723: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000148f96f8 14. /build/src/Interpreters/InterpreterCreateQuery.cpp:2352: DB::InterpreterCreateQuery::execute() @ 0x0000000014905a41 15. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88dc9 16. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 17. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 18. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 19. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 20. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 21. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 22. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 23. ? @ 0x00007fbc6213eac3 24. ? @ 0x00007fbc621d0850 2025.07.28 12:03:33.221935 [ 62053 ] {75e67a01-b4bf-43f6-acae-3f194fbbbce0} executeQuery: Code: 57. DB::Exception: Table test_5.test already exists. (TABLE_ALREADY_EXISTS) (version 25.3.6.10636.altinitytest (altinity build)) (from [::1]:47870) (comment: 02025_having_filter_column.sql) (query 2, line 3) (in query: CREATE TABLE test (`d` DateTime, `a` String, `b` UInt64) ENGINE = MergeTree PARTITION BY toDate(d) ORDER BY d SETTINGS index_granularity = 52425, min_bytes_for_wide_part = 0, ratio_of_defaults_for_sparse_serialization = 0., replace_long_file_name_to_hash = false, max_file_name_length = 49, min_bytes_for_full_part_storage = 0, compact_parts_max_bytes_to_buffer = 339106911, compact_parts_max_granules_to_buffer = 63, compact_parts_merge_max_bytes_to_prefetch_part = 27403824, merge_max_block_size = 24122, old_parts_lifetime = 480., 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 = 9470899268, index_granularity_bytes = 16871333, use_const_adaptive_granularity = false, enable_index_granularity_compression = false, 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 = true, marks_compress_block_size = 37221, primary_key_compress_block_size = 84184, 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. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000a06a8eb 4. /build/src/Interpreters/InterpreterCreateQuery.cpp:1824: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x0000000014901d53 5. /build/src/Interpreters/InterpreterCreateQuery.cpp:1743: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000148f9aa9 6. /build/src/Interpreters/InterpreterCreateQuery.cpp:2352: DB::InterpreterCreateQuery::execute() @ 0x0000000014905a41 7. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88dc9 8. /build/src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x0000000014c8ca7b 9. /build/src/Interpreters/DDLWorker.cpp:510: DB::DDLWorker::tryExecuteQuery(DB::DDLTaskBase&, std::shared_ptr const&, bool) @ 0x00000000144dab9e 10. /build/src/Interpreters/DDLWorker.cpp:675: DB::DDLWorker::processTask(DB::DDLTaskBase&, std::shared_ptr const&, bool) @ 0x00000000144d8ffe 11. /build/src/Databases/DatabaseReplicatedWorker.cpp:372: DB::DatabaseReplicatedDDLWorker::tryEnqueueAndExecuteEntry(DB::DDLLogEntry&, std::shared_ptr, bool) @ 0x0000000013dc29ab 12. /build/src/Databases/DatabaseReplicated.cpp:1139: DB::DatabaseReplicated::tryEnqueueReplicatedDDL(std::shared_ptr const&, std::shared_ptr, DB::QueryFlags) @ 0x0000000013d9f73c 13. /build/src/Interpreters/InterpreterCreateQuery.cpp:1723: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000148f96f8 14. /build/src/Interpreters/InterpreterCreateQuery.cpp:2352: DB::InterpreterCreateQuery::execute() @ 0x0000000014905a41 15. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88dc9 16. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 17. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 18. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 19. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 20. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 21. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 22. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 23. ? @ 0x00007fbc6213eac3 24. ? @ 0x00007fbc621d0850 2025.07.28 12:03:33.231659 [ 62053 ] {} TCPHandler: Code: 57. DB::Exception: Table test_5.test already exists. (TABLE_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000a06a8eb 4. /build/src/Interpreters/InterpreterCreateQuery.cpp:1824: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x0000000014901d53 5. /build/src/Interpreters/InterpreterCreateQuery.cpp:1743: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000148f9aa9 6. /build/src/Interpreters/InterpreterCreateQuery.cpp:2352: DB::InterpreterCreateQuery::execute() @ 0x0000000014905a41 7. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88dc9 8. /build/src/Interpreters/executeQuery.cpp:1761: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x0000000014c8ca7b 9. /build/src/Interpreters/DDLWorker.cpp:510: DB::DDLWorker::tryExecuteQuery(DB::DDLTaskBase&, std::shared_ptr const&, bool) @ 0x00000000144dab9e 10. /build/src/Interpreters/DDLWorker.cpp:675: DB::DDLWorker::processTask(DB::DDLTaskBase&, std::shared_ptr const&, bool) @ 0x00000000144d8ffe 11. /build/src/Databases/DatabaseReplicatedWorker.cpp:372: DB::DatabaseReplicatedDDLWorker::tryEnqueueAndExecuteEntry(DB::DDLLogEntry&, std::shared_ptr, bool) @ 0x0000000013dc29ab 12. /build/src/Databases/DatabaseReplicated.cpp:1139: DB::DatabaseReplicated::tryEnqueueReplicatedDDL(std::shared_ptr const&, std::shared_ptr, DB::QueryFlags) @ 0x0000000013d9f73c 13. /build/src/Interpreters/InterpreterCreateQuery.cpp:1723: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000148f96f8 14. /build/src/Interpreters/InterpreterCreateQuery.cpp:2352: DB::InterpreterCreateQuery::execute() @ 0x0000000014905a41 15. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88dc9 16. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 17. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 18. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 19. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 20. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 21. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 22. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 23. ? @ 0x00007fbc6213eac3 24. ? @ 0x00007fbc621d0850 2025.07.28 12:03:33.381584 [ 3969 ] {} test_13.rmt2 (7f9b740d-015c-470e-8cc6-8ba33be0dc63): auto DB::StorageReplicatedMergeTree::processQueueEntry(ReplicatedMergeTreeQueue::SelectedEntryPtr)::(anonymous class)::operator()(LogEntryPtr &) const: Code: 86. DB::HTTPException: Received error from remote server http://146b4357c08d:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Ftest%2F01165%2Ftest_13%2Frmt%2Freplicas%2F1&part=20250728_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.6.10636.altinitytest (altinity build)) '. (RECEIVED_ERROR_FROM_REMOTE_IO_SERVER), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.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 const&, int&&, String const&, unsigned long&&, String const&) @ 0x000000000feda8d9 4. /build/src/IO/HTTPCommon.cpp:104: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x000000000feda6e2 5. /build/src/IO/HTTPCommon.cpp:93: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x000000000feda537 6. /build/src/IO/ReadWriteBufferFromHTTP.cpp:277: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x000000001184a4c4 7. /build/src/IO/ReadWriteBufferFromHTTP.cpp:285: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x000000001184a615 8. /build/src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x000000001184ae59 9. /build/src/IO/ReadWriteBufferFromHTTP.cpp:472: void std::__function::__policy_invoker::__call_impl[abi:se190107]>(std::__function::__policy_storage const*) @ 0x000000001184cedd 10. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001184858b 11. /build/src/IO/ReadWriteBufferFromHTTP.cpp:465: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x000000001184bf0b 12. /build/src/IO/ReadBuffer.h:60: DB::ReadBuffer::next() @ 0x000000000a148c7b 13. /build/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) @ 0x0000000011849fb2 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]>&)>&, 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&) @ 0x0000000011841980 15. /build/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) @ 0x000000001621208e 16. /build/src/Storages/StorageReplicatedMergeTree.cpp:5228: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl[abi:se190107] const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000015f9a5fe 17. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000015ed8bfd 18. /build/src/Storages/StorageReplicatedMergeTree.cpp:2514: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x0000000015ec9aab 19. /build/src/Storages/StorageReplicatedMergeTree.cpp:2349: DB::StorageReplicatedMergeTree::executeLogEntry(DB::ReplicatedMergeTreeLogEntry&) @ 0x0000000015eba91b 20. /build/src/Storages/StorageReplicatedMergeTree.cpp:3876: bool std::__function::__policy_invoker&)>::__call_impl[abi:se190107])::$_1, bool (std::shared_ptr&)>>(std::__function::__policy_storage const*, std::shared_ptr&) @ 0x0000000015f9837e 21. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000165d6fc3 22. /build/src/Storages/StorageReplicatedMergeTree.cpp:3872: DB::StorageReplicatedMergeTree::processQueueEntry(std::shared_ptr) @ 0x0000000015efc18a 23. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001624c1b2 24. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000162f9c70 25. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x00000000162fa55a 26. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc6653 27. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000000fccc4c3 28. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc3d92 29. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fcca080 30. ? @ 0x00007fbc6213eac3 31. ? @ 0x00007fbc621d0850 (version 25.3.6.10636.altinitytest (altinity build)) 2025.07.28 12:03:34.088780 [ 62056 ] {} 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. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception>&, String>(int, FormatStringHelperImpl>&>::type, std::type_identity::type>, std::basic_string_view>&, String&&) @ 0x000000001385a5eb 4. /build/src/Access/SettingsConstraints.cpp:376: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000013859b18 5. /build/src/Access/SettingsConstraints.cpp:300: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000013858faf 6. /build/src/Access/SettingsConstraints.cpp:209: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000013859223 7. /build/src/Interpreters/Context.cpp:2690: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000014436134 8. /build/src/Interpreters/Context.cpp:2729: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x000000001443662b 9. /build/src/Server/HTTPHandler.cpp:457: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000001686d165 10. /build/src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x0000000016870807 11. /build/src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x0000000016907e99 12. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 13. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 14. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 15. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 16. ? @ 0x00007fbc6213eac3 17. ? @ 0x00007fbc621d0850 (version 25.3.6.10636.altinitytest (altinity build)) 2025.07.28 12:03:34.160047 [ 3974 ] {} test_13.rmt2 (7f9b740d-015c-470e-8cc6-8ba33be0dc63): auto DB::StorageReplicatedMergeTree::processQueueEntry(ReplicatedMergeTreeQueue::SelectedEntryPtr)::(anonymous class)::operator()(LogEntryPtr &) const: Code: 86. DB::HTTPException: Received error from remote server http://146b4357c08d:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Ftest%2F01165%2Ftest_13%2Frmt%2Freplicas%2F1&part=20250728_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.6.10636.altinitytest (altinity build)) '. (RECEIVED_ERROR_FROM_REMOTE_IO_SERVER), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.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 const&, int&&, String const&, unsigned long&&, String const&) @ 0x000000000feda8d9 4. /build/src/IO/HTTPCommon.cpp:104: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x000000000feda6e2 5. /build/src/IO/HTTPCommon.cpp:93: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x000000000feda537 6. /build/src/IO/ReadWriteBufferFromHTTP.cpp:277: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x000000001184a4c4 7. /build/src/IO/ReadWriteBufferFromHTTP.cpp:285: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x000000001184a615 8. /build/src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x000000001184ae59 9. /build/src/IO/ReadWriteBufferFromHTTP.cpp:472: void std::__function::__policy_invoker::__call_impl[abi:se190107]>(std::__function::__policy_storage const*) @ 0x000000001184cedd 10. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001184858b 11. /build/src/IO/ReadWriteBufferFromHTTP.cpp:465: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x000000001184bf0b 12. /build/src/IO/ReadBuffer.h:60: DB::ReadBuffer::next() @ 0x000000000a148c7b 13. /build/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) @ 0x0000000011849fb2 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]>&)>&, 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&) @ 0x0000000011841980 15. /build/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) @ 0x000000001621208e 16. /build/src/Storages/StorageReplicatedMergeTree.cpp:5228: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl[abi:se190107] const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000015f9a5fe 17. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000015ed8bfd 18. /build/src/Storages/StorageReplicatedMergeTree.cpp:2514: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x0000000015ec9aab 19. /build/src/Storages/StorageReplicatedMergeTree.cpp:2349: DB::StorageReplicatedMergeTree::executeLogEntry(DB::ReplicatedMergeTreeLogEntry&) @ 0x0000000015eba91b 20. /build/src/Storages/StorageReplicatedMergeTree.cpp:3876: bool std::__function::__policy_invoker&)>::__call_impl[abi:se190107])::$_1, bool (std::shared_ptr&)>>(std::__function::__policy_storage const*, std::shared_ptr&) @ 0x0000000015f9837e 21. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000165d6fc3 22. /build/src/Storages/StorageReplicatedMergeTree.cpp:3872: DB::StorageReplicatedMergeTree::processQueueEntry(std::shared_ptr) @ 0x0000000015efc18a 23. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001624c1b2 24. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000162f9c70 25. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x00000000162fa55a 26. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc6653 27. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000000fccc4c3 28. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc3d92 29. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fcca080 30. ? @ 0x00007fbc6213eac3 31. ? @ 0x00007fbc621d0850 (version 25.3.6.10636.altinitytest (altinity build)) 2025.07.28 12:03:35.232416 [ 3977 ] {} test_13.rmt2 (7f9b740d-015c-470e-8cc6-8ba33be0dc63): auto DB::StorageReplicatedMergeTree::processQueueEntry(ReplicatedMergeTreeQueue::SelectedEntryPtr)::(anonymous class)::operator()(LogEntryPtr &) const: Code: 86. DB::HTTPException: Received error from remote server http://146b4357c08d:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Ftest%2F01165%2Ftest_13%2Frmt%2Freplicas%2F1&part=20250728_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.6.10636.altinitytest (altinity build)) '. (RECEIVED_ERROR_FROM_REMOTE_IO_SERVER), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.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 const&, int&&, String const&, unsigned long&&, String const&) @ 0x000000000feda8d9 4. /build/src/IO/HTTPCommon.cpp:104: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x000000000feda6e2 5. /build/src/IO/HTTPCommon.cpp:93: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x000000000feda537 6. /build/src/IO/ReadWriteBufferFromHTTP.cpp:277: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x000000001184a4c4 7. /build/src/IO/ReadWriteBufferFromHTTP.cpp:285: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x000000001184a615 8. /build/src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x000000001184ae59 9. /build/src/IO/ReadWriteBufferFromHTTP.cpp:472: void std::__function::__policy_invoker::__call_impl[abi:se190107]>(std::__function::__policy_storage const*) @ 0x000000001184cedd 10. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001184858b 11. /build/src/IO/ReadWriteBufferFromHTTP.cpp:465: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x000000001184bf0b 12. /build/src/IO/ReadBuffer.h:60: DB::ReadBuffer::next() @ 0x000000000a148c7b 13. /build/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) @ 0x0000000011849fb2 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]>&)>&, 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&) @ 0x0000000011841980 15. /build/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) @ 0x000000001621208e 16. /build/src/Storages/StorageReplicatedMergeTree.cpp:5228: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl[abi:se190107] const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000015f9a5fe 17. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000015ed8bfd 18. /build/src/Storages/StorageReplicatedMergeTree.cpp:2514: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x0000000015ec9aab 19. /build/src/Storages/StorageReplicatedMergeTree.cpp:2349: DB::StorageReplicatedMergeTree::executeLogEntry(DB::ReplicatedMergeTreeLogEntry&) @ 0x0000000015eba91b 20. /build/src/Storages/StorageReplicatedMergeTree.cpp:3876: bool std::__function::__policy_invoker&)>::__call_impl[abi:se190107])::$_1, bool (std::shared_ptr&)>>(std::__function::__policy_storage const*, std::shared_ptr&) @ 0x0000000015f9837e 21. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000165d6fc3 22. /build/src/Storages/StorageReplicatedMergeTree.cpp:3872: DB::StorageReplicatedMergeTree::processQueueEntry(std::shared_ptr) @ 0x0000000015efc18a 23. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001624c1b2 24. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000162f9c70 25. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x00000000162fa55a 26. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc6653 27. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000000fccc4c3 28. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc3d92 29. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fcca080 30. ? @ 0x00007fbc6213eac3 31. ? @ 0x00007fbc621d0850 (version 25.3.6.10636.altinitytest (altinity build)) 2025.07.28 12:03:35.238881 [ 62053 ] {e78f8163-cdb4-4765-8861-6d34f9a13c49} executeQuery: Code: 57. DB::Exception: Table test_9.t2 already exists. (TABLE_ALREADY_EXISTS) (version 25.3.6.10636.altinitytest (altinity build)) (from [::1]:47906) (comment: 01031_pmj_new_any_semi_join.sql) (query 4, line 5) (in query: CREATE TABLE t2 (`x` UInt32, `s` String) ENGINE = MergeTree ORDER BY tuple() SETTINGS index_granularity = 23077, min_bytes_for_wide_part = 0, ratio_of_defaults_for_sparse_serialization = 0.9346053004264832, 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 = 93687202, compact_parts_max_granules_to_buffer = 211, compact_parts_merge_max_bytes_to_prefetch_part = 18257446, merge_max_block_size = 14893, old_parts_lifetime = 376., prefer_fetch_merged_part_size_threshold = 8890590737, vertical_merge_algorithm_min_rows_to_activate = 157113, vertical_merge_algorithm_min_columns_to_activate = 1, min_merge_bytes_to_use_direct_io = 6874004028, index_granularity_bytes = 26363283, 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 = 98768, primary_key_compress_block_size = 68116, 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. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000a06a8eb 4. /build/src/Interpreters/InterpreterCreateQuery.cpp:1824: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x0000000014901d53 5. /build/src/Interpreters/InterpreterCreateQuery.cpp:1743: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000148f9aa9 6. /build/src/Interpreters/InterpreterCreateQuery.cpp:2352: DB::InterpreterCreateQuery::execute() @ 0x0000000014905a41 7. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88dc9 8. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 9. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 10. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 11. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 12. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 13. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 14. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 15. ? @ 0x00007fbc6213eac3 16. ? @ 0x00007fbc621d0850 2025.07.28 12:03:35.257612 [ 62053 ] {} TCPHandler: Code: 57. DB::Exception: Table test_9.t2 already exists. (TABLE_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000a06a8eb 4. /build/src/Interpreters/InterpreterCreateQuery.cpp:1824: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x0000000014901d53 5. /build/src/Interpreters/InterpreterCreateQuery.cpp:1743: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000148f9aa9 6. /build/src/Interpreters/InterpreterCreateQuery.cpp:2352: DB::InterpreterCreateQuery::execute() @ 0x0000000014905a41 7. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88dc9 8. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 9. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 10. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 11. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 12. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 13. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 14. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 15. ? @ 0x00007fbc6213eac3 16. ? @ 0x00007fbc621d0850 2025.07.28 12:03:35.275830 [ 5029 ] {2f0efcb2-578f-4e39-a18f-46e700e58969} executeQuery: Code: 57. DB::Exception: Table system.columns already exists. (TABLE_ALREADY_EXISTS) (version 25.3.6.10636.altinitytest (altinity build)) (from [::1]:47910) (comment: 01445_create_table_as_table_function.sh) (query 1, line 1) (in query: CREATE TABLE system.columns AS numbers(10);), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000a06a8eb 4. /build/src/Interpreters/InterpreterCreateQuery.cpp:1824: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x0000000014901d53 5. /build/src/Interpreters/InterpreterCreateQuery.cpp:1743: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000148f9aa9 6. /build/src/Interpreters/InterpreterCreateQuery.cpp:2352: DB::InterpreterCreateQuery::execute() @ 0x0000000014905a41 7. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88dc9 8. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 9. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 10. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 11. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 12. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 13. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 14. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 15. ? @ 0x00007fbc6213eac3 16. ? @ 0x00007fbc621d0850 2025.07.28 12:03:35.308687 [ 5029 ] {} TCPHandler: Code: 57. DB::Exception: Table system.columns already exists. (TABLE_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000a06a8eb 4. /build/src/Interpreters/InterpreterCreateQuery.cpp:1824: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x0000000014901d53 5. /build/src/Interpreters/InterpreterCreateQuery.cpp:1743: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000148f9aa9 6. /build/src/Interpreters/InterpreterCreateQuery.cpp:2352: DB::InterpreterCreateQuery::execute() @ 0x0000000014905a41 7. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88dc9 8. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 9. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 10. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 11. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 12. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 13. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 14. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 15. ? @ 0x00007fbc6213eac3 16. ? @ 0x00007fbc621d0850 2025.07.28 12:03:36.224217 [ 3967 ] {} test_13.rmt2 (7f9b740d-015c-470e-8cc6-8ba33be0dc63): auto DB::StorageReplicatedMergeTree::processQueueEntry(ReplicatedMergeTreeQueue::SelectedEntryPtr)::(anonymous class)::operator()(LogEntryPtr &) const: Code: 86. DB::HTTPException: Received error from remote server http://146b4357c08d:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Ftest%2F01165%2Ftest_13%2Frmt%2Freplicas%2F1&part=20250728_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.6.10636.altinitytest (altinity build)) '. (RECEIVED_ERROR_FROM_REMOTE_IO_SERVER), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.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 const&, int&&, String const&, unsigned long&&, String const&) @ 0x000000000feda8d9 4. /build/src/IO/HTTPCommon.cpp:104: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x000000000feda6e2 5. /build/src/IO/HTTPCommon.cpp:93: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x000000000feda537 6. /build/src/IO/ReadWriteBufferFromHTTP.cpp:277: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x000000001184a4c4 7. /build/src/IO/ReadWriteBufferFromHTTP.cpp:285: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x000000001184a615 8. /build/src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x000000001184ae59 9. /build/src/IO/ReadWriteBufferFromHTTP.cpp:472: void std::__function::__policy_invoker::__call_impl[abi:se190107]>(std::__function::__policy_storage const*) @ 0x000000001184cedd 10. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001184858b 11. /build/src/IO/ReadWriteBufferFromHTTP.cpp:465: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x000000001184bf0b 12. /build/src/IO/ReadBuffer.h:60: DB::ReadBuffer::next() @ 0x000000000a148c7b 13. /build/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) @ 0x0000000011849fb2 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]>&)>&, 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&) @ 0x0000000011841980 15. /build/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) @ 0x000000001621208e 16. /build/src/Storages/StorageReplicatedMergeTree.cpp:5228: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl[abi:se190107] const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000015f9a5fe 17. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000015ed8bfd 18. /build/src/Storages/StorageReplicatedMergeTree.cpp:2514: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x0000000015ec9aab 19. /build/src/Storages/StorageReplicatedMergeTree.cpp:2349: DB::StorageReplicatedMergeTree::executeLogEntry(DB::ReplicatedMergeTreeLogEntry&) @ 0x0000000015eba91b 20. /build/src/Storages/StorageReplicatedMergeTree.cpp:3876: bool std::__function::__policy_invoker&)>::__call_impl[abi:se190107])::$_1, bool (std::shared_ptr&)>>(std::__function::__policy_storage const*, std::shared_ptr&) @ 0x0000000015f9837e 21. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000165d6fc3 22. /build/src/Storages/StorageReplicatedMergeTree.cpp:3872: DB::StorageReplicatedMergeTree::processQueueEntry(std::shared_ptr) @ 0x0000000015efc18a 23. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001624c1b2 24. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000162f9c70 25. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x00000000162fa55a 26. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc6653 27. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000000fccc4c3 28. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc3d92 29. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fcca080 30. ? @ 0x00007fbc6213eac3 31. ? @ 0x00007fbc621d0850 (version 25.3.6.10636.altinitytest (altinity build)) 2025.07.28 12:03:37.299910 [ 3972 ] {} test_13.rmt2 (7f9b740d-015c-470e-8cc6-8ba33be0dc63): auto DB::StorageReplicatedMergeTree::processQueueEntry(ReplicatedMergeTreeQueue::SelectedEntryPtr)::(anonymous class)::operator()(LogEntryPtr &) const: Code: 86. DB::HTTPException: Received error from remote server http://146b4357c08d:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Ftest%2F01165%2Ftest_13%2Frmt%2Freplicas%2F1&part=20250728_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.6.10636.altinitytest (altinity build)) '. (RECEIVED_ERROR_FROM_REMOTE_IO_SERVER), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.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 const&, int&&, String const&, unsigned long&&, String const&) @ 0x000000000feda8d9 4. /build/src/IO/HTTPCommon.cpp:104: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x000000000feda6e2 5. /build/src/IO/HTTPCommon.cpp:93: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x000000000feda537 6. /build/src/IO/ReadWriteBufferFromHTTP.cpp:277: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x000000001184a4c4 7. /build/src/IO/ReadWriteBufferFromHTTP.cpp:285: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x000000001184a615 8. /build/src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x000000001184ae59 9. /build/src/IO/ReadWriteBufferFromHTTP.cpp:472: void std::__function::__policy_invoker::__call_impl[abi:se190107]>(std::__function::__policy_storage const*) @ 0x000000001184cedd 10. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001184858b 11. /build/src/IO/ReadWriteBufferFromHTTP.cpp:465: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x000000001184bf0b 12. /build/src/IO/ReadBuffer.h:60: DB::ReadBuffer::next() @ 0x000000000a148c7b 13. /build/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) @ 0x0000000011849fb2 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]>&)>&, 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&) @ 0x0000000011841980 15. /build/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) @ 0x000000001621208e 16. /build/src/Storages/StorageReplicatedMergeTree.cpp:5228: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl[abi:se190107] const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000015f9a5fe 17. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000015ed8bfd 18. /build/src/Storages/StorageReplicatedMergeTree.cpp:2514: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x0000000015ec9aab 19. /build/src/Storages/StorageReplicatedMergeTree.cpp:2349: DB::StorageReplicatedMergeTree::executeLogEntry(DB::ReplicatedMergeTreeLogEntry&) @ 0x0000000015eba91b 20. /build/src/Storages/StorageReplicatedMergeTree.cpp:3876: bool std::__function::__policy_invoker&)>::__call_impl[abi:se190107])::$_1, bool (std::shared_ptr&)>>(std::__function::__policy_storage const*, std::shared_ptr&) @ 0x0000000015f9837e 21. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000165d6fc3 22. /build/src/Storages/StorageReplicatedMergeTree.cpp:3872: DB::StorageReplicatedMergeTree::processQueueEntry(std::shared_ptr) @ 0x0000000015efc18a 23. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001624c1b2 24. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000162f9c70 25. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x00000000162fa55a 26. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc6653 27. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000000fccc4c3 28. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc3d92 29. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fcca080 30. ? @ 0x00007fbc6213eac3 31. ? @ 0x00007fbc621d0850 (version 25.3.6.10636.altinitytest (altinity build)) 2025.07.28 12:03:37.452243 [ 3969 ] {} test_13.rmt2 (7f9b740d-015c-470e-8cc6-8ba33be0dc63): auto DB::StorageReplicatedMergeTree::processQueueEntry(ReplicatedMergeTreeQueue::SelectedEntryPtr)::(anonymous class)::operator()(LogEntryPtr &) const: Code: 86. DB::HTTPException: Received error from remote server http://146b4357c08d:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Ftest%2F01165%2Ftest_13%2Frmt%2Freplicas%2F1&part=20250728_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.6.10636.altinitytest (altinity build)) '. (RECEIVED_ERROR_FROM_REMOTE_IO_SERVER), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.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 const&, int&&, String const&, unsigned long&&, String const&) @ 0x000000000feda8d9 4. /build/src/IO/HTTPCommon.cpp:104: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x000000000feda6e2 5. /build/src/IO/HTTPCommon.cpp:93: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x000000000feda537 6. /build/src/IO/ReadWriteBufferFromHTTP.cpp:277: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x000000001184a4c4 7. /build/src/IO/ReadWriteBufferFromHTTP.cpp:285: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x000000001184a615 8. /build/src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x000000001184ae59 9. /build/src/IO/ReadWriteBufferFromHTTP.cpp:472: void std::__function::__policy_invoker::__call_impl[abi:se190107]>(std::__function::__policy_storage const*) @ 0x000000001184cedd 10. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001184858b 11. /build/src/IO/ReadWriteBufferFromHTTP.cpp:465: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x000000001184bf0b 12. /build/src/IO/ReadBuffer.h:60: DB::ReadBuffer::next() @ 0x000000000a148c7b 13. /build/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) @ 0x0000000011849fb2 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]>&)>&, 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&) @ 0x0000000011841980 15. /build/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) @ 0x000000001621208e 16. /build/src/Storages/StorageReplicatedMergeTree.cpp:5228: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl[abi:se190107] const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000015f9a5fe 17. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000015ed8bfd 18. /build/src/Storages/StorageReplicatedMergeTree.cpp:2514: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x0000000015ec9aab 19. /build/src/Storages/StorageReplicatedMergeTree.cpp:2349: DB::StorageReplicatedMergeTree::executeLogEntry(DB::ReplicatedMergeTreeLogEntry&) @ 0x0000000015eba91b 20. /build/src/Storages/StorageReplicatedMergeTree.cpp:3876: bool std::__function::__policy_invoker&)>::__call_impl[abi:se190107])::$_1, bool (std::shared_ptr&)>>(std::__function::__policy_storage const*, std::shared_ptr&) @ 0x0000000015f9837e 21. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000165d6fc3 22. /build/src/Storages/StorageReplicatedMergeTree.cpp:3872: DB::StorageReplicatedMergeTree::processQueueEntry(std::shared_ptr) @ 0x0000000015efc18a 23. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001624c1b2 24. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000162f9c70 25. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x00000000162fa55a 26. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc6653 27. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000000fccc4c3 28. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc3d92 29. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fcca080 30. ? @ 0x00007fbc6213eac3 31. ? @ 0x00007fbc621d0850 (version 25.3.6.10636.altinitytest (altinity build)) 2025.07.28 12:03:37.757912 [ 3967 ] {} test_13.rmt2 (7f9b740d-015c-470e-8cc6-8ba33be0dc63): auto DB::StorageReplicatedMergeTree::processQueueEntry(ReplicatedMergeTreeQueue::SelectedEntryPtr)::(anonymous class)::operator()(LogEntryPtr &) const: Code: 86. DB::HTTPException: Received error from remote server http://146b4357c08d:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Ftest%2F01165%2Ftest_13%2Frmt%2Freplicas%2F1&part=20250728_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.6.10636.altinitytest (altinity build)) '. (RECEIVED_ERROR_FROM_REMOTE_IO_SERVER), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.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 const&, int&&, String const&, unsigned long&&, String const&) @ 0x000000000feda8d9 4. /build/src/IO/HTTPCommon.cpp:104: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x000000000feda6e2 5. /build/src/IO/HTTPCommon.cpp:93: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x000000000feda537 6. /build/src/IO/ReadWriteBufferFromHTTP.cpp:277: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x000000001184a4c4 7. /build/src/IO/ReadWriteBufferFromHTTP.cpp:285: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x000000001184a615 8. /build/src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x000000001184ae59 9. /build/src/IO/ReadWriteBufferFromHTTP.cpp:472: void std::__function::__policy_invoker::__call_impl[abi:se190107]>(std::__function::__policy_storage const*) @ 0x000000001184cedd 10. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001184858b 11. /build/src/IO/ReadWriteBufferFromHTTP.cpp:465: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x000000001184bf0b 12. /build/src/IO/ReadBuffer.h:60: DB::ReadBuffer::next() @ 0x000000000a148c7b 13. /build/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) @ 0x0000000011849fb2 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]>&)>&, 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&) @ 0x0000000011841980 15. /build/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) @ 0x000000001621208e 16. /build/src/Storages/StorageReplicatedMergeTree.cpp:5228: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl[abi:se190107] const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000015f9a5fe 17. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000015ed8bfd 18. /build/src/Storages/StorageReplicatedMergeTree.cpp:2514: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x0000000015ec9aab 19. /build/src/Storages/StorageReplicatedMergeTree.cpp:2349: DB::StorageReplicatedMergeTree::executeLogEntry(DB::ReplicatedMergeTreeLogEntry&) @ 0x0000000015eba91b 20. /build/src/Storages/StorageReplicatedMergeTree.cpp:3876: bool std::__function::__policy_invoker&)>::__call_impl[abi:se190107])::$_1, bool (std::shared_ptr&)>>(std::__function::__policy_storage const*, std::shared_ptr&) @ 0x0000000015f9837e 21. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000165d6fc3 22. /build/src/Storages/StorageReplicatedMergeTree.cpp:3872: DB::StorageReplicatedMergeTree::processQueueEntry(std::shared_ptr) @ 0x0000000015efc18a 23. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001624c1b2 24. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000162f9c70 25. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x00000000162fa55a 26. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc6653 27. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000000fccc4c3 28. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc3d92 29. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fcca080 30. ? @ 0x00007fbc6213eac3 31. ? @ 0x00007fbc621d0850 (version 25.3.6.10636.altinitytest (altinity build)) 2025.07.28 12:03:38.265368 [ 4900 ] {fef042e7-7d8d-45e7-938b-1f0375bc8c50} executeQuery: Code: 57. DB::Exception: Table test_7.one_00458 already exists. (TABLE_ALREADY_EXISTS) (version 25.3.6.10636.altinitytest (altinity build)) (from [::1]:47884) (comment: 00458_merge_type_cast.sql) (query 59, line 87) (in query: CREATE TABLE one_00458 (x String) ENGINE = Memory;), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000a06a8eb 4. /build/src/Interpreters/InterpreterCreateQuery.cpp:1824: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x0000000014901d53 5. /build/src/Interpreters/InterpreterCreateQuery.cpp:1743: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000148f9aa9 6. /build/src/Interpreters/InterpreterCreateQuery.cpp:2352: DB::InterpreterCreateQuery::execute() @ 0x0000000014905a41 7. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88dc9 8. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 9. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 10. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 11. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 12. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 13. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 14. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 15. ? @ 0x00007fbc6213eac3 16. ? @ 0x00007fbc621d0850 2025.07.28 12:03:38.275153 [ 4900 ] {} TCPHandler: Code: 57. DB::Exception: Table test_7.one_00458 already exists. (TABLE_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000a06a8eb 4. /build/src/Interpreters/InterpreterCreateQuery.cpp:1824: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x0000000014901d53 5. /build/src/Interpreters/InterpreterCreateQuery.cpp:1743: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000148f9aa9 6. /build/src/Interpreters/InterpreterCreateQuery.cpp:2352: DB::InterpreterCreateQuery::execute() @ 0x0000000014905a41 7. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88dc9 8. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 9. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 10. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 11. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 12. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 13. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 14. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 15. ? @ 0x00007fbc6213eac3 16. ? @ 0x00007fbc621d0850 2025.07.28 12:03:38.284029 [ 3970 ] {} test_13.rmt2 (7f9b740d-015c-470e-8cc6-8ba33be0dc63): auto DB::StorageReplicatedMergeTree::processQueueEntry(ReplicatedMergeTreeQueue::SelectedEntryPtr)::(anonymous class)::operator()(LogEntryPtr &) const: Code: 86. DB::HTTPException: Received error from remote server http://146b4357c08d:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Ftest%2F01165%2Ftest_13%2Frmt%2Freplicas%2F1&part=20250728_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.6.10636.altinitytest (altinity build)) '. (RECEIVED_ERROR_FROM_REMOTE_IO_SERVER), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.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 const&, int&&, String const&, unsigned long&&, String const&) @ 0x000000000feda8d9 4. /build/src/IO/HTTPCommon.cpp:104: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x000000000feda6e2 5. /build/src/IO/HTTPCommon.cpp:93: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x000000000feda537 6. /build/src/IO/ReadWriteBufferFromHTTP.cpp:277: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x000000001184a4c4 7. /build/src/IO/ReadWriteBufferFromHTTP.cpp:285: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x000000001184a615 8. /build/src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x000000001184ae59 9. /build/src/IO/ReadWriteBufferFromHTTP.cpp:472: void std::__function::__policy_invoker::__call_impl[abi:se190107]>(std::__function::__policy_storage const*) @ 0x000000001184cedd 10. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001184858b 11. /build/src/IO/ReadWriteBufferFromHTTP.cpp:465: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x000000001184bf0b 12. /build/src/IO/ReadBuffer.h:60: DB::ReadBuffer::next() @ 0x000000000a148c7b 13. /build/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) @ 0x0000000011849fb2 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]>&)>&, 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&) @ 0x0000000011841980 15. /build/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) @ 0x000000001621208e 16. /build/src/Storages/StorageReplicatedMergeTree.cpp:5228: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl[abi:se190107] const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000015f9a5fe 17. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000015ed8bfd 18. /build/src/Storages/StorageReplicatedMergeTree.cpp:2514: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x0000000015ec9aab 19. /build/src/Storages/StorageReplicatedMergeTree.cpp:2349: DB::StorageReplicatedMergeTree::executeLogEntry(DB::ReplicatedMergeTreeLogEntry&) @ 0x0000000015eba91b 20. /build/src/Storages/StorageReplicatedMergeTree.cpp:3876: bool std::__function::__policy_invoker&)>::__call_impl[abi:se190107])::$_1, bool (std::shared_ptr&)>>(std::__function::__policy_storage const*, std::shared_ptr&) @ 0x0000000015f9837e 21. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000165d6fc3 22. /build/src/Storages/StorageReplicatedMergeTree.cpp:3872: DB::StorageReplicatedMergeTree::processQueueEntry(std::shared_ptr) @ 0x0000000015efc18a 23. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001624c1b2 24. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000162f9c70 25. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x00000000162fa55a 26. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc6653 27. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000000fccc4c3 28. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc3d92 29. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fcca080 30. ? @ 0x00007fbc6213eac3 31. ? @ 0x00007fbc621d0850 (version 25.3.6.10636.altinitytest (altinity build)) 2025.07.28 12:03:38.638861 [ 3971 ] {} test_13.rmt2 (7f9b740d-015c-470e-8cc6-8ba33be0dc63): auto DB::StorageReplicatedMergeTree::processQueueEntry(ReplicatedMergeTreeQueue::SelectedEntryPtr)::(anonymous class)::operator()(LogEntryPtr &) const: Code: 86. DB::HTTPException: Received error from remote server http://146b4357c08d:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Ftest%2F01165%2Ftest_13%2Frmt%2Freplicas%2F1&part=20250728_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.6.10636.altinitytest (altinity build)) '. (RECEIVED_ERROR_FROM_REMOTE_IO_SERVER), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.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 const&, int&&, String const&, unsigned long&&, String const&) @ 0x000000000feda8d9 4. /build/src/IO/HTTPCommon.cpp:104: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x000000000feda6e2 5. /build/src/IO/HTTPCommon.cpp:93: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x000000000feda537 6. /build/src/IO/ReadWriteBufferFromHTTP.cpp:277: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x000000001184a4c4 7. /build/src/IO/ReadWriteBufferFromHTTP.cpp:285: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x000000001184a615 8. /build/src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x000000001184ae59 9. /build/src/IO/ReadWriteBufferFromHTTP.cpp:472: void std::__function::__policy_invoker::__call_impl[abi:se190107]>(std::__function::__policy_storage const*) @ 0x000000001184cedd 10. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001184858b 11. /build/src/IO/ReadWriteBufferFromHTTP.cpp:465: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x000000001184bf0b 12. /build/src/IO/ReadBuffer.h:60: DB::ReadBuffer::next() @ 0x000000000a148c7b 13. /build/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) @ 0x0000000011849fb2 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]>&)>&, 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&) @ 0x0000000011841980 15. /build/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) @ 0x000000001621208e 16. /build/src/Storages/StorageReplicatedMergeTree.cpp:5228: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl[abi:se190107] const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000015f9a5fe 17. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000015ed8bfd 18. /build/src/Storages/StorageReplicatedMergeTree.cpp:2514: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x0000000015ec9aab 19. /build/src/Storages/StorageReplicatedMergeTree.cpp:2349: DB::StorageReplicatedMergeTree::executeLogEntry(DB::ReplicatedMergeTreeLogEntry&) @ 0x0000000015eba91b 20. /build/src/Storages/StorageReplicatedMergeTree.cpp:3876: bool std::__function::__policy_invoker&)>::__call_impl[abi:se190107])::$_1, bool (std::shared_ptr&)>>(std::__function::__policy_storage const*, std::shared_ptr&) @ 0x0000000015f9837e 21. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000165d6fc3 22. /build/src/Storages/StorageReplicatedMergeTree.cpp:3872: DB::StorageReplicatedMergeTree::processQueueEntry(std::shared_ptr) @ 0x0000000015efc18a 23. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001624c1b2 24. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000162f9c70 25. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x00000000162fa55a 26. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc6653 27. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000000fccc4c3 28. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc3d92 29. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fcca080 30. ? @ 0x00007fbc6213eac3 31. ? @ 0x00007fbc621d0850 (version 25.3.6.10636.altinitytest (altinity build)) 2025.07.28 12:03:39.465102 [ 3964 ] {} test_13.rmt2 (7f9b740d-015c-470e-8cc6-8ba33be0dc63): auto DB::StorageReplicatedMergeTree::processQueueEntry(ReplicatedMergeTreeQueue::SelectedEntryPtr)::(anonymous class)::operator()(LogEntryPtr &) const: Code: 86. DB::HTTPException: Received error from remote server http://146b4357c08d:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Ftest%2F01165%2Ftest_13%2Frmt%2Freplicas%2F1&part=20250728_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.6.10636.altinitytest (altinity build)) '. (RECEIVED_ERROR_FROM_REMOTE_IO_SERVER), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.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 const&, int&&, String const&, unsigned long&&, String const&) @ 0x000000000feda8d9 4. /build/src/IO/HTTPCommon.cpp:104: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x000000000feda6e2 5. /build/src/IO/HTTPCommon.cpp:93: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x000000000feda537 6. /build/src/IO/ReadWriteBufferFromHTTP.cpp:277: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x000000001184a4c4 7. /build/src/IO/ReadWriteBufferFromHTTP.cpp:285: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x000000001184a615 8. /build/src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x000000001184ae59 9. /build/src/IO/ReadWriteBufferFromHTTP.cpp:472: void std::__function::__policy_invoker::__call_impl[abi:se190107]>(std::__function::__policy_storage const*) @ 0x000000001184cedd 10. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001184858b 11. /build/src/IO/ReadWriteBufferFromHTTP.cpp:465: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x000000001184bf0b 12. /build/src/IO/ReadBuffer.h:60: DB::ReadBuffer::next() @ 0x000000000a148c7b 13. /build/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) @ 0x0000000011849fb2 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]>&)>&, 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&) @ 0x0000000011841980 15. /build/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) @ 0x000000001621208e 16. /build/src/Storages/StorageReplicatedMergeTree.cpp:5228: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl[abi:se190107] const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000015f9a5fe 17. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000015ed8bfd 18. /build/src/Storages/StorageReplicatedMergeTree.cpp:2514: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x0000000015ec9aab 19. /build/src/Storages/StorageReplicatedMergeTree.cpp:2349: DB::StorageReplicatedMergeTree::executeLogEntry(DB::ReplicatedMergeTreeLogEntry&) @ 0x0000000015eba91b 20. /build/src/Storages/StorageReplicatedMergeTree.cpp:3876: bool std::__function::__policy_invoker&)>::__call_impl[abi:se190107])::$_1, bool (std::shared_ptr&)>>(std::__function::__policy_storage const*, std::shared_ptr&) @ 0x0000000015f9837e 21. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000165d6fc3 22. /build/src/Storages/StorageReplicatedMergeTree.cpp:3872: DB::StorageReplicatedMergeTree::processQueueEntry(std::shared_ptr) @ 0x0000000015efc18a 23. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001624c1b2 24. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000162f9c70 25. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x00000000162fa55a 26. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc6653 27. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000000fccc4c3 28. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc3d92 29. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fcca080 30. ? @ 0x00007fbc6213eac3 31. ? @ 0x00007fbc621d0850 (version 25.3.6.10636.altinitytest (altinity build)) 2025.07.28 12:03:40.113450 [ 3968 ] {} test_13.rmt2 (7f9b740d-015c-470e-8cc6-8ba33be0dc63): auto DB::StorageReplicatedMergeTree::processQueueEntry(ReplicatedMergeTreeQueue::SelectedEntryPtr)::(anonymous class)::operator()(LogEntryPtr &) const: Code: 86. DB::HTTPException: Received error from remote server http://146b4357c08d:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Ftest%2F01165%2Ftest_13%2Frmt%2Freplicas%2F1&part=20250728_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.6.10636.altinitytest (altinity build)) '. (RECEIVED_ERROR_FROM_REMOTE_IO_SERVER), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.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 const&, int&&, String const&, unsigned long&&, String const&) @ 0x000000000feda8d9 4. /build/src/IO/HTTPCommon.cpp:104: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x000000000feda6e2 5. /build/src/IO/HTTPCommon.cpp:93: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x000000000feda537 6. /build/src/IO/ReadWriteBufferFromHTTP.cpp:277: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x000000001184a4c4 7. /build/src/IO/ReadWriteBufferFromHTTP.cpp:285: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x000000001184a615 8. /build/src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x000000001184ae59 9. /build/src/IO/ReadWriteBufferFromHTTP.cpp:472: void std::__function::__policy_invoker::__call_impl[abi:se190107]>(std::__function::__policy_storage const*) @ 0x000000001184cedd 10. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001184858b 11. /build/src/IO/ReadWriteBufferFromHTTP.cpp:465: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x000000001184bf0b 12. /build/src/IO/ReadBuffer.h:60: DB::ReadBuffer::next() @ 0x000000000a148c7b 13. /build/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) @ 0x0000000011849fb2 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]>&)>&, 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&) @ 0x0000000011841980 15. /build/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) @ 0x000000001621208e 16. /build/src/Storages/StorageReplicatedMergeTree.cpp:5228: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl[abi:se190107] const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000015f9a5fe 17. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000015ed8bfd 18. /build/src/Storages/StorageReplicatedMergeTree.cpp:2514: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x0000000015ec9aab 19. /build/src/Storages/StorageReplicatedMergeTree.cpp:2349: DB::StorageReplicatedMergeTree::executeLogEntry(DB::ReplicatedMergeTreeLogEntry&) @ 0x0000000015eba91b 20. /build/src/Storages/StorageReplicatedMergeTree.cpp:3876: bool std::__function::__policy_invoker&)>::__call_impl[abi:se190107])::$_1, bool (std::shared_ptr&)>>(std::__function::__policy_storage const*, std::shared_ptr&) @ 0x0000000015f9837e 21. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000165d6fc3 22. /build/src/Storages/StorageReplicatedMergeTree.cpp:3872: DB::StorageReplicatedMergeTree::processQueueEntry(std::shared_ptr) @ 0x0000000015efc18a 23. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001624c1b2 24. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000162f9c70 25. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x00000000162fa55a 26. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc6653 27. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000000fccc4c3 28. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc3d92 29. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fcca080 30. ? @ 0x00007fbc6213eac3 31. ? @ 0x00007fbc621d0850 (version 25.3.6.10636.altinitytest (altinity build)) 2025.07.28 12:03:40.346100 [ 3977 ] {} test_13.rmt2 (7f9b740d-015c-470e-8cc6-8ba33be0dc63): auto DB::StorageReplicatedMergeTree::processQueueEntry(ReplicatedMergeTreeQueue::SelectedEntryPtr)::(anonymous class)::operator()(LogEntryPtr &) const: Code: 86. DB::HTTPException: Received error from remote server http://146b4357c08d:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Ftest%2F01165%2Ftest_13%2Frmt%2Freplicas%2F1&part=20250728_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.6.10636.altinitytest (altinity build)) '. (RECEIVED_ERROR_FROM_REMOTE_IO_SERVER), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.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 const&, int&&, String const&, unsigned long&&, String const&) @ 0x000000000feda8d9 4. /build/src/IO/HTTPCommon.cpp:104: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x000000000feda6e2 5. /build/src/IO/HTTPCommon.cpp:93: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x000000000feda537 6. /build/src/IO/ReadWriteBufferFromHTTP.cpp:277: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x000000001184a4c4 7. /build/src/IO/ReadWriteBufferFromHTTP.cpp:285: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x000000001184a615 8. /build/src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x000000001184ae59 9. /build/src/IO/ReadWriteBufferFromHTTP.cpp:472: void std::__function::__policy_invoker::__call_impl[abi:se190107]>(std::__function::__policy_storage const*) @ 0x000000001184cedd 10. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001184858b 11. /build/src/IO/ReadWriteBufferFromHTTP.cpp:465: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x000000001184bf0b 12. /build/src/IO/ReadBuffer.h:60: DB::ReadBuffer::next() @ 0x000000000a148c7b 13. /build/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) @ 0x0000000011849fb2 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]>&)>&, 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&) @ 0x0000000011841980 15. /build/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) @ 0x000000001621208e 16. /build/src/Storages/StorageReplicatedMergeTree.cpp:5228: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl[abi:se190107] const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000015f9a5fe 17. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000015ed8bfd 18. /build/src/Storages/StorageReplicatedMergeTree.cpp:2514: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x0000000015ec9aab 19. /build/src/Storages/StorageReplicatedMergeTree.cpp:2349: DB::StorageReplicatedMergeTree::executeLogEntry(DB::ReplicatedMergeTreeLogEntry&) @ 0x0000000015eba91b 20. /build/src/Storages/StorageReplicatedMergeTree.cpp:3876: bool std::__function::__policy_invoker&)>::__call_impl[abi:se190107])::$_1, bool (std::shared_ptr&)>>(std::__function::__policy_storage const*, std::shared_ptr&) @ 0x0000000015f9837e 21. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000165d6fc3 22. /build/src/Storages/StorageReplicatedMergeTree.cpp:3872: DB::StorageReplicatedMergeTree::processQueueEntry(std::shared_ptr) @ 0x0000000015efc18a 23. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001624c1b2 24. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000162f9c70 25. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x00000000162fa55a 26. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc6653 27. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000000fccc4c3 28. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc3d92 29. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fcca080 30. ? @ 0x00007fbc6213eac3 31. ? @ 0x00007fbc621d0850 (version 25.3.6.10636.altinitytest (altinity build)) 2025.07.28 12:03:40.661982 [ 3960 ] {} test_13.rmt2 (7f9b740d-015c-470e-8cc6-8ba33be0dc63): auto DB::StorageReplicatedMergeTree::processQueueEntry(ReplicatedMergeTreeQueue::SelectedEntryPtr)::(anonymous class)::operator()(LogEntryPtr &) const: Code: 86. DB::HTTPException: Received error from remote server http://146b4357c08d:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Ftest%2F01165%2Ftest_13%2Frmt%2Freplicas%2F1&part=20250728_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.6.10636.altinitytest (altinity build)) '. (RECEIVED_ERROR_FROM_REMOTE_IO_SERVER), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.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 const&, int&&, String const&, unsigned long&&, String const&) @ 0x000000000feda8d9 4. /build/src/IO/HTTPCommon.cpp:104: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x000000000feda6e2 5. /build/src/IO/HTTPCommon.cpp:93: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x000000000feda537 6. /build/src/IO/ReadWriteBufferFromHTTP.cpp:277: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x000000001184a4c4 7. /build/src/IO/ReadWriteBufferFromHTTP.cpp:285: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x000000001184a615 8. /build/src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x000000001184ae59 9. /build/src/IO/ReadWriteBufferFromHTTP.cpp:472: void std::__function::__policy_invoker::__call_impl[abi:se190107]>(std::__function::__policy_storage const*) @ 0x000000001184cedd 10. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001184858b 11. /build/src/IO/ReadWriteBufferFromHTTP.cpp:465: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x000000001184bf0b 12. /build/src/IO/ReadBuffer.h:60: DB::ReadBuffer::next() @ 0x000000000a148c7b 13. /build/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) @ 0x0000000011849fb2 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]>&)>&, 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&) @ 0x0000000011841980 15. /build/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) @ 0x000000001621208e 16. /build/src/Storages/StorageReplicatedMergeTree.cpp:5228: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl[abi:se190107] const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000015f9a5fe 17. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000015ed8bfd 18. /build/src/Storages/StorageReplicatedMergeTree.cpp:2514: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x0000000015ec9aab 19. /build/src/Storages/StorageReplicatedMergeTree.cpp:2349: DB::StorageReplicatedMergeTree::executeLogEntry(DB::ReplicatedMergeTreeLogEntry&) @ 0x0000000015eba91b 20. /build/src/Storages/StorageReplicatedMergeTree.cpp:3876: bool std::__function::__policy_invoker&)>::__call_impl[abi:se190107])::$_1, bool (std::shared_ptr&)>>(std::__function::__policy_storage const*, std::shared_ptr&) @ 0x0000000015f9837e 21. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000165d6fc3 22. /build/src/Storages/StorageReplicatedMergeTree.cpp:3872: DB::StorageReplicatedMergeTree::processQueueEntry(std::shared_ptr) @ 0x0000000015efc18a 23. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001624c1b2 24. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000162f9c70 25. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x00000000162fa55a 26. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc6653 27. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000000fccc4c3 28. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc3d92 29. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fcca080 30. ? @ 0x00007fbc6213eac3 31. ? @ 0x00007fbc621d0850 (version 25.3.6.10636.altinitytest (altinity build)) 2025.07.28 12:03:40.881821 [ 3965 ] {} test_13.rmt2 (7f9b740d-015c-470e-8cc6-8ba33be0dc63): auto DB::StorageReplicatedMergeTree::processQueueEntry(ReplicatedMergeTreeQueue::SelectedEntryPtr)::(anonymous class)::operator()(LogEntryPtr &) const: Code: 86. DB::HTTPException: Received error from remote server http://146b4357c08d:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Ftest%2F01165%2Ftest_13%2Frmt%2Freplicas%2F1&part=20250728_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.6.10636.altinitytest (altinity build)) '. (RECEIVED_ERROR_FROM_REMOTE_IO_SERVER), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.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 const&, int&&, String const&, unsigned long&&, String const&) @ 0x000000000feda8d9 4. /build/src/IO/HTTPCommon.cpp:104: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x000000000feda6e2 5. /build/src/IO/HTTPCommon.cpp:93: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x000000000feda537 6. /build/src/IO/ReadWriteBufferFromHTTP.cpp:277: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x000000001184a4c4 7. /build/src/IO/ReadWriteBufferFromHTTP.cpp:285: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x000000001184a615 8. /build/src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x000000001184ae59 9. /build/src/IO/ReadWriteBufferFromHTTP.cpp:472: void std::__function::__policy_invoker::__call_impl[abi:se190107]>(std::__function::__policy_storage const*) @ 0x000000001184cedd 10. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001184858b 11. /build/src/IO/ReadWriteBufferFromHTTP.cpp:465: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x000000001184bf0b 12. /build/src/IO/ReadBuffer.h:60: DB::ReadBuffer::next() @ 0x000000000a148c7b 13. /build/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) @ 0x0000000011849fb2 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]>&)>&, 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&) @ 0x0000000011841980 15. /build/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) @ 0x000000001621208e 16. /build/src/Storages/StorageReplicatedMergeTree.cpp:5228: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl[abi:se190107] const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000015f9a5fe 17. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000015ed8bfd 18. /build/src/Storages/StorageReplicatedMergeTree.cpp:2514: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x0000000015ec9aab 19. /build/src/Storages/StorageReplicatedMergeTree.cpp:2349: DB::StorageReplicatedMergeTree::executeLogEntry(DB::ReplicatedMergeTreeLogEntry&) @ 0x0000000015eba91b 20. /build/src/Storages/StorageReplicatedMergeTree.cpp:3876: bool std::__function::__policy_invoker&)>::__call_impl[abi:se190107])::$_1, bool (std::shared_ptr&)>>(std::__function::__policy_storage const*, std::shared_ptr&) @ 0x0000000015f9837e 21. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000165d6fc3 22. /build/src/Storages/StorageReplicatedMergeTree.cpp:3872: DB::StorageReplicatedMergeTree::processQueueEntry(std::shared_ptr) @ 0x0000000015efc18a 23. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001624c1b2 24. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000162f9c70 25. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x00000000162fa55a 26. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc6653 27. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000000fccc4c3 28. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc3d92 29. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fcca080 30. ? @ 0x00007fbc6213eac3 31. ? @ 0x00007fbc621d0850 (version 25.3.6.10636.altinitytest (altinity build)) 2025.07.28 12:03:41.297011 [ 62056 ] {8cf27451-8873-43a9-adc6-2ce6f79ae87e} executeQuery: Code: 36. DB::Exception: Cannot sleep infinite, very large or negative amount of time (not implemented). (BAD_ARGUMENTS) (version 25.3.6.10636.altinitytest (altinity build)) (from [::1]:47992) (comment: 01655_sleep_infinite_float.sql) (query 1, line 1) (in query: SELECT sleep(nan);), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000000a074fcb 4. /build/src/Functions/sleep.cpp:119: DB::(anonymous namespace)::FunctionSleep<(DB::(anonymous namespace)::FunctionSleepVariant)0>::execute(std::vector> const&, std::shared_ptr const&, bool) const @ 0x000000000e6d165b 5. /build/src/Functions/sleep.cpp:100: DB::(anonymous namespace)::FunctionSleep<(DB::(anonymous namespace)::FunctionSleepVariant)0>::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000e6d104f 6. /build/src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000012d9965a 7. /build/src/Functions/IFunction.cpp:351: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d93b02 8. /build/src/Functions/IFunction.cpp:420: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d95059 9. /build/src/Functions/IFunction.cpp:498: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d95c72 10. /build/src/Interpreters/ActionsDAG.cpp:812: DB::ActionsDAG::evaluatePartialResult(std::unordered_map, std::equal_to, std::allocator>>&, std::vector> const&, unsigned long, bool) @ 0x0000000013fa38cc 11. /build/src/Interpreters/ActionsDAG.cpp:892: DB::ActionsDAG::updateHeader(DB::Block const&) const @ 0x0000000013fa29a8 12. /build/src/Processors/Transforms/ExpressionTransform.cpp:10: DB::ExpressionTransform::transformHeader(DB::Block const&, DB::ActionsDAG const&) @ 0x0000000016c0afd2 13. /build/src/Processors/QueryPlan/ExpressionStep.cpp:38: DB::ExpressionStep::ExpressionStep(DB::Block const&, DB::ActionsDAG) @ 0x0000000016db8ad1 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107](DB::Block const&, DB::ActionsDAG&&) @ 0x00000000131ee01a 15. /build/src/Planner/Planner.cpp:392: DB::(anonymous namespace)::addExpressionStep(DB::QueryPlan&, std::shared_ptr&, String const&, std::unordered_set, std::hash>, std::equal_to>, std::allocator>>&) @ 0x000000001498191d 16. /build/src/Planner/Planner.cpp:1648: DB::Planner::buildPlanForQueryNode() @ 0x000000001497b7aa 17. /build/src/Planner/Planner.cpp:1308: DB::Planner::buildQueryPlanIfNeeded() @ 0x000000001497685c 18. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:255: DB::InterpreterSelectQueryAnalyzer::getQueryPlan() @ 0x000000001497476d 19. /build/src/Interpreters/executeQuery.cpp:1405: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88806 20. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 21. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 22. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 23. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 24. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 25. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 26. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 27. ? @ 0x00007fbc6213eac3 28. ? @ 0x00007fbc621d0850 2025.07.28 12:03:41.323983 [ 62056 ] {} 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. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000000a074fcb 4. /build/src/Functions/sleep.cpp:119: DB::(anonymous namespace)::FunctionSleep<(DB::(anonymous namespace)::FunctionSleepVariant)0>::execute(std::vector> const&, std::shared_ptr const&, bool) const @ 0x000000000e6d165b 5. /build/src/Functions/sleep.cpp:100: DB::(anonymous namespace)::FunctionSleep<(DB::(anonymous namespace)::FunctionSleepVariant)0>::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000e6d104f 6. /build/src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000012d9965a 7. /build/src/Functions/IFunction.cpp:351: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d93b02 8. /build/src/Functions/IFunction.cpp:420: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d95059 9. /build/src/Functions/IFunction.cpp:498: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d95c72 10. /build/src/Interpreters/ActionsDAG.cpp:812: DB::ActionsDAG::evaluatePartialResult(std::unordered_map, std::equal_to, std::allocator>>&, std::vector> const&, unsigned long, bool) @ 0x0000000013fa38cc 11. /build/src/Interpreters/ActionsDAG.cpp:892: DB::ActionsDAG::updateHeader(DB::Block const&) const @ 0x0000000013fa29a8 12. /build/src/Processors/Transforms/ExpressionTransform.cpp:10: DB::ExpressionTransform::transformHeader(DB::Block const&, DB::ActionsDAG const&) @ 0x0000000016c0afd2 13. /build/src/Processors/QueryPlan/ExpressionStep.cpp:38: DB::ExpressionStep::ExpressionStep(DB::Block const&, DB::ActionsDAG) @ 0x0000000016db8ad1 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107](DB::Block const&, DB::ActionsDAG&&) @ 0x00000000131ee01a 15. /build/src/Planner/Planner.cpp:392: DB::(anonymous namespace)::addExpressionStep(DB::QueryPlan&, std::shared_ptr&, String const&, std::unordered_set, std::hash>, std::equal_to>, std::allocator>>&) @ 0x000000001498191d 16. /build/src/Planner/Planner.cpp:1648: DB::Planner::buildPlanForQueryNode() @ 0x000000001497b7aa 17. /build/src/Planner/Planner.cpp:1308: DB::Planner::buildQueryPlanIfNeeded() @ 0x000000001497685c 18. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:255: DB::InterpreterSelectQueryAnalyzer::getQueryPlan() @ 0x000000001497476d 19. /build/src/Interpreters/executeQuery.cpp:1405: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88806 20. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 21. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 22. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 23. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 24. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 25. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 26. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 27. ? @ 0x00007fbc6213eac3 28. ? @ 0x00007fbc621d0850 2025.07.28 12:03:41.472168 [ 62056 ] {12de0ade-cc5a-4334-9987-75e9a2dd4825} executeQuery: Code: 36. DB::Exception: Cannot sleep infinite, very large or negative amount of time (not implemented). (BAD_ARGUMENTS) (version 25.3.6.10636.altinitytest (altinity build)) (from [::1]:47992) (comment: 01655_sleep_infinite_float.sql) (query 2, line 2) (in query: SELECT sleep(inf);), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000000a074fcb 4. /build/src/Functions/sleep.cpp:119: DB::(anonymous namespace)::FunctionSleep<(DB::(anonymous namespace)::FunctionSleepVariant)0>::execute(std::vector> const&, std::shared_ptr const&, bool) const @ 0x000000000e6d165b 5. /build/src/Functions/sleep.cpp:100: DB::(anonymous namespace)::FunctionSleep<(DB::(anonymous namespace)::FunctionSleepVariant)0>::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000e6d104f 6. /build/src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000012d9965a 7. /build/src/Functions/IFunction.cpp:351: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d93b02 8. /build/src/Functions/IFunction.cpp:420: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d95059 9. /build/src/Functions/IFunction.cpp:498: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d95c72 10. /build/src/Interpreters/ActionsDAG.cpp:812: DB::ActionsDAG::evaluatePartialResult(std::unordered_map, std::equal_to, std::allocator>>&, std::vector> const&, unsigned long, bool) @ 0x0000000013fa38cc 11. /build/src/Interpreters/ActionsDAG.cpp:892: DB::ActionsDAG::updateHeader(DB::Block const&) const @ 0x0000000013fa29a8 12. /build/src/Processors/Transforms/ExpressionTransform.cpp:10: DB::ExpressionTransform::transformHeader(DB::Block const&, DB::ActionsDAG const&) @ 0x0000000016c0afd2 13. /build/src/Processors/QueryPlan/ExpressionStep.cpp:38: DB::ExpressionStep::ExpressionStep(DB::Block const&, DB::ActionsDAG) @ 0x0000000016db8ad1 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107](DB::Block const&, DB::ActionsDAG&&) @ 0x00000000131ee01a 15. /build/src/Planner/Planner.cpp:392: DB::(anonymous namespace)::addExpressionStep(DB::QueryPlan&, std::shared_ptr&, String const&, std::unordered_set, std::hash>, std::equal_to>, std::allocator>>&) @ 0x000000001498191d 16. /build/src/Planner/Planner.cpp:1648: DB::Planner::buildPlanForQueryNode() @ 0x000000001497b7aa 17. /build/src/Planner/Planner.cpp:1308: DB::Planner::buildQueryPlanIfNeeded() @ 0x000000001497685c 18. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:255: DB::InterpreterSelectQueryAnalyzer::getQueryPlan() @ 0x000000001497476d 19. /build/src/Interpreters/executeQuery.cpp:1405: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88806 20. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 21. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 22. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 23. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 24. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 25. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 26. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 27. ? @ 0x00007fbc6213eac3 28. ? @ 0x00007fbc621d0850 2025.07.28 12:03:41.504783 [ 62056 ] {} 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. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000000a074fcb 4. /build/src/Functions/sleep.cpp:119: DB::(anonymous namespace)::FunctionSleep<(DB::(anonymous namespace)::FunctionSleepVariant)0>::execute(std::vector> const&, std::shared_ptr const&, bool) const @ 0x000000000e6d165b 5. /build/src/Functions/sleep.cpp:100: DB::(anonymous namespace)::FunctionSleep<(DB::(anonymous namespace)::FunctionSleepVariant)0>::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000e6d104f 6. /build/src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000012d9965a 7. /build/src/Functions/IFunction.cpp:351: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d93b02 8. /build/src/Functions/IFunction.cpp:420: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d95059 9. /build/src/Functions/IFunction.cpp:498: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d95c72 10. /build/src/Interpreters/ActionsDAG.cpp:812: DB::ActionsDAG::evaluatePartialResult(std::unordered_map, std::equal_to, std::allocator>>&, std::vector> const&, unsigned long, bool) @ 0x0000000013fa38cc 11. /build/src/Interpreters/ActionsDAG.cpp:892: DB::ActionsDAG::updateHeader(DB::Block const&) const @ 0x0000000013fa29a8 12. /build/src/Processors/Transforms/ExpressionTransform.cpp:10: DB::ExpressionTransform::transformHeader(DB::Block const&, DB::ActionsDAG const&) @ 0x0000000016c0afd2 13. /build/src/Processors/QueryPlan/ExpressionStep.cpp:38: DB::ExpressionStep::ExpressionStep(DB::Block const&, DB::ActionsDAG) @ 0x0000000016db8ad1 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107](DB::Block const&, DB::ActionsDAG&&) @ 0x00000000131ee01a 15. /build/src/Planner/Planner.cpp:392: DB::(anonymous namespace)::addExpressionStep(DB::QueryPlan&, std::shared_ptr&, String const&, std::unordered_set, std::hash>, std::equal_to>, std::allocator>>&) @ 0x000000001498191d 16. /build/src/Planner/Planner.cpp:1648: DB::Planner::buildPlanForQueryNode() @ 0x000000001497b7aa 17. /build/src/Planner/Planner.cpp:1308: DB::Planner::buildQueryPlanIfNeeded() @ 0x000000001497685c 18. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:255: DB::InterpreterSelectQueryAnalyzer::getQueryPlan() @ 0x000000001497476d 19. /build/src/Interpreters/executeQuery.cpp:1405: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88806 20. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 21. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 22. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 23. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 24. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 25. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 26. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 27. ? @ 0x00007fbc6213eac3 28. ? @ 0x00007fbc621d0850 2025.07.28 12:03:41.910580 [ 3974 ] {} test_13.rmt2 (7f9b740d-015c-470e-8cc6-8ba33be0dc63): auto DB::StorageReplicatedMergeTree::processQueueEntry(ReplicatedMergeTreeQueue::SelectedEntryPtr)::(anonymous class)::operator()(LogEntryPtr &) const: Code: 86. DB::HTTPException: Received error from remote server http://146b4357c08d:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Ftest%2F01165%2Ftest_13%2Frmt%2Freplicas%2F1&part=20250728_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.6.10636.altinitytest (altinity build)) '. (RECEIVED_ERROR_FROM_REMOTE_IO_SERVER), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.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 const&, int&&, String const&, unsigned long&&, String const&) @ 0x000000000feda8d9 4. /build/src/IO/HTTPCommon.cpp:104: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x000000000feda6e2 5. /build/src/IO/HTTPCommon.cpp:93: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x000000000feda537 6. /build/src/IO/ReadWriteBufferFromHTTP.cpp:277: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x000000001184a4c4 7. /build/src/IO/ReadWriteBufferFromHTTP.cpp:285: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x000000001184a615 8. /build/src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x000000001184ae59 9. /build/src/IO/ReadWriteBufferFromHTTP.cpp:472: void std::__function::__policy_invoker::__call_impl[abi:se190107]>(std::__function::__policy_storage const*) @ 0x000000001184cedd 10. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001184858b 11. /build/src/IO/ReadWriteBufferFromHTTP.cpp:465: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x000000001184bf0b 12. /build/src/IO/ReadBuffer.h:60: DB::ReadBuffer::next() @ 0x000000000a148c7b 13. /build/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) @ 0x0000000011849fb2 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]>&)>&, 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&) @ 0x0000000011841980 15. /build/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) @ 0x000000001621208e 16. /build/src/Storages/StorageReplicatedMergeTree.cpp:5228: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl[abi:se190107] const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000015f9a5fe 17. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000015ed8bfd 18. /build/src/Storages/StorageReplicatedMergeTree.cpp:2514: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x0000000015ec9aab 19. /build/src/Storages/StorageReplicatedMergeTree.cpp:2349: DB::StorageReplicatedMergeTree::executeLogEntry(DB::ReplicatedMergeTreeLogEntry&) @ 0x0000000015eba91b 20. /build/src/Storages/StorageReplicatedMergeTree.cpp:3876: bool std::__function::__policy_invoker&)>::__call_impl[abi:se190107])::$_1, bool (std::shared_ptr&)>>(std::__function::__policy_storage const*, std::shared_ptr&) @ 0x0000000015f9837e 21. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000165d6fc3 22. /build/src/Storages/StorageReplicatedMergeTree.cpp:3872: DB::StorageReplicatedMergeTree::processQueueEntry(std::shared_ptr) @ 0x0000000015efc18a 23. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001624c1b2 24. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000162f9c70 25. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x00000000162fa55a 26. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc6653 27. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000000fccc4c3 28. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc3d92 29. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fcca080 30. ? @ 0x00007fbc6213eac3 31. ? @ 0x00007fbc621d0850 (version 25.3.6.10636.altinitytest (altinity build)) 2025.07.28 12:03:42.153204 [ 3970 ] {} test_13.rmt2 (7f9b740d-015c-470e-8cc6-8ba33be0dc63): auto DB::StorageReplicatedMergeTree::processQueueEntry(ReplicatedMergeTreeQueue::SelectedEntryPtr)::(anonymous class)::operator()(LogEntryPtr &) const: Code: 86. DB::HTTPException: Received error from remote server http://146b4357c08d:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Ftest%2F01165%2Ftest_13%2Frmt%2Freplicas%2F1&part=20250728_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.6.10636.altinitytest (altinity build)) '. (RECEIVED_ERROR_FROM_REMOTE_IO_SERVER), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.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 const&, int&&, String const&, unsigned long&&, String const&) @ 0x000000000feda8d9 4. /build/src/IO/HTTPCommon.cpp:104: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x000000000feda6e2 5. /build/src/IO/HTTPCommon.cpp:93: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x000000000feda537 6. /build/src/IO/ReadWriteBufferFromHTTP.cpp:277: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x000000001184a4c4 7. /build/src/IO/ReadWriteBufferFromHTTP.cpp:285: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x000000001184a615 8. /build/src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x000000001184ae59 9. /build/src/IO/ReadWriteBufferFromHTTP.cpp:472: void std::__function::__policy_invoker::__call_impl[abi:se190107]>(std::__function::__policy_storage const*) @ 0x000000001184cedd 10. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001184858b 11. /build/src/IO/ReadWriteBufferFromHTTP.cpp:465: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x000000001184bf0b 12. /build/src/IO/ReadBuffer.h:60: DB::ReadBuffer::next() @ 0x000000000a148c7b 13. /build/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) @ 0x0000000011849fb2 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]>&)>&, 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&) @ 0x0000000011841980 15. /build/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) @ 0x000000001621208e 16. /build/src/Storages/StorageReplicatedMergeTree.cpp:5228: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl[abi:se190107] const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000015f9a5fe 17. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000015ed8bfd 18. /build/src/Storages/StorageReplicatedMergeTree.cpp:2514: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x0000000015ec9aab 19. /build/src/Storages/StorageReplicatedMergeTree.cpp:2349: DB::StorageReplicatedMergeTree::executeLogEntry(DB::ReplicatedMergeTreeLogEntry&) @ 0x0000000015eba91b 20. /build/src/Storages/StorageReplicatedMergeTree.cpp:3876: bool std::__function::__policy_invoker&)>::__call_impl[abi:se190107])::$_1, bool (std::shared_ptr&)>>(std::__function::__policy_storage const*, std::shared_ptr&) @ 0x0000000015f9837e 21. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000165d6fc3 22. /build/src/Storages/StorageReplicatedMergeTree.cpp:3872: DB::StorageReplicatedMergeTree::processQueueEntry(std::shared_ptr) @ 0x0000000015efc18a 23. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001624c1b2 24. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000162f9c70 25. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x00000000162fa55a 26. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc6653 27. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000000fccc4c3 28. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc3d92 29. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fcca080 30. ? @ 0x00007fbc6213eac3 31. ? @ 0x00007fbc621d0850 (version 25.3.6.10636.altinitytest (altinity build)) 2025.07.28 12:03:42.889658 [ 3969 ] {} test_13.rmt2 (7f9b740d-015c-470e-8cc6-8ba33be0dc63): auto DB::StorageReplicatedMergeTree::processQueueEntry(ReplicatedMergeTreeQueue::SelectedEntryPtr)::(anonymous class)::operator()(LogEntryPtr &) const: Code: 86. DB::HTTPException: Received error from remote server http://146b4357c08d:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Ftest%2F01165%2Ftest_13%2Frmt%2Freplicas%2F1&part=20250728_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.6.10636.altinitytest (altinity build)) '. (RECEIVED_ERROR_FROM_REMOTE_IO_SERVER), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.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 const&, int&&, String const&, unsigned long&&, String const&) @ 0x000000000feda8d9 4. /build/src/IO/HTTPCommon.cpp:104: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x000000000feda6e2 5. /build/src/IO/HTTPCommon.cpp:93: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x000000000feda537 6. /build/src/IO/ReadWriteBufferFromHTTP.cpp:277: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x000000001184a4c4 7. /build/src/IO/ReadWriteBufferFromHTTP.cpp:285: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x000000001184a615 8. /build/src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x000000001184ae59 9. /build/src/IO/ReadWriteBufferFromHTTP.cpp:472: void std::__function::__policy_invoker::__call_impl[abi:se190107]>(std::__function::__policy_storage const*) @ 0x000000001184cedd 10. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001184858b 11. /build/src/IO/ReadWriteBufferFromHTTP.cpp:465: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x000000001184bf0b 12. /build/src/IO/ReadBuffer.h:60: DB::ReadBuffer::next() @ 0x000000000a148c7b 13. /build/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) @ 0x0000000011849fb2 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]>&)>&, 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&) @ 0x0000000011841980 15. /build/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) @ 0x000000001621208e 16. /build/src/Storages/StorageReplicatedMergeTree.cpp:5228: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl[abi:se190107] const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000015f9a5fe 17. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000015ed8bfd 18. /build/src/Storages/StorageReplicatedMergeTree.cpp:2514: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x0000000015ec9aab 19. /build/src/Storages/StorageReplicatedMergeTree.cpp:2349: DB::StorageReplicatedMergeTree::executeLogEntry(DB::ReplicatedMergeTreeLogEntry&) @ 0x0000000015eba91b 20. /build/src/Storages/StorageReplicatedMergeTree.cpp:3876: bool std::__function::__policy_invoker&)>::__call_impl[abi:se190107])::$_1, bool (std::shared_ptr&)>>(std::__function::__policy_storage const*, std::shared_ptr&) @ 0x0000000015f9837e 21. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000165d6fc3 22. /build/src/Storages/StorageReplicatedMergeTree.cpp:3872: DB::StorageReplicatedMergeTree::processQueueEntry(std::shared_ptr) @ 0x0000000015efc18a 23. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001624c1b2 24. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000162f9c70 25. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x00000000162fa55a 26. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc6653 27. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000000fccc4c3 28. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc3d92 29. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fcca080 30. ? @ 0x00007fbc6213eac3 31. ? @ 0x00007fbc621d0850 (version 25.3.6.10636.altinitytest (altinity build)) 2025.07.28 12:03:43.009598 [ 5029 ] {47932be7-7d4d-4bc6-9fbb-e6bcaba50a1f} executeQuery: Code: 70. DB::Exception: Cannot convert NULL to a non-nullable type: while converting source column src to destination column val. (CANNOT_CONVERT_TYPE) (version 25.3.6.10636.altinitytest (altinity build)) (from [::1]:35092) (comment: 00690_insert_select_converting_exception_message.sh) (query 1, line 1) (in query: INSERT INTO test_00690 SELECT NULL AS src SETTINGS insert_null_as_default=0;), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000000a074fcb 4. /build/src/Functions/FunctionsConversion.h:5730: DB::detail::FunctionCast::prepareUnpackDictionaries(std::shared_ptr const&, std::shared_ptr const&) const @ 0x0000000012ddc730 5. /build/src/Functions/FunctionsConversion.h:3444: DB::detail::FunctionCast::prepare(std::vector> const&) const @ 0x0000000012ddbeb0 6. /build/src/Interpreters/ActionsDAG.cpp:403: DB::ActionsDAG::addFunctionImpl(std::shared_ptr const&, std::vector>, std::vector>, String, std::shared_ptr, bool) @ 0x0000000013f9c709 7. /build/src/Interpreters/ActionsDAG.cpp:362: DB::ActionsDAG::addFunction(std::shared_ptr const&, std::vector>, String) @ 0x0000000013f9d19b 8. /build/src/Interpreters/ActionsDAG.cpp:1637: DB::ActionsDAG::makeConvertingActions(std::vector> const&, std::vector> const&, DB::ActionsDAG::MatchColumnsMode, bool, bool, std::unordered_map, std::equal_to, std::allocator>>*) @ 0x0000000013faa20e 9. /build/src/Interpreters/InterpreterInsertQuery.cpp:620: DB::InterpreterInsertQuery::buildInsertSelectPipeline(DB::ASTInsertQuery&, std::shared_ptr) @ 0x0000000014930b2b 10. /build/src/Interpreters/InterpreterInsertQuery.cpp:870: DB::InterpreterInsertQuery::execute() @ 0x0000000014933e3d 11. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88dc9 12. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 13. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 14. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 15. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 16. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 17. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 18. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 19. ? @ 0x00007fbc6213eac3 20. ? @ 0x00007fbc621d0850 2025.07.28 12:03:43.024953 [ 5029 ] {} TCPHandler: Code: 70. DB::Exception: Cannot convert NULL to a non-nullable type: while converting source column src to destination column val. (CANNOT_CONVERT_TYPE), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000000a074fcb 4. /build/src/Functions/FunctionsConversion.h:5730: DB::detail::FunctionCast::prepareUnpackDictionaries(std::shared_ptr const&, std::shared_ptr const&) const @ 0x0000000012ddc730 5. /build/src/Functions/FunctionsConversion.h:3444: DB::detail::FunctionCast::prepare(std::vector> const&) const @ 0x0000000012ddbeb0 6. /build/src/Interpreters/ActionsDAG.cpp:403: DB::ActionsDAG::addFunctionImpl(std::shared_ptr const&, std::vector>, std::vector>, String, std::shared_ptr, bool) @ 0x0000000013f9c709 7. /build/src/Interpreters/ActionsDAG.cpp:362: DB::ActionsDAG::addFunction(std::shared_ptr const&, std::vector>, String) @ 0x0000000013f9d19b 8. /build/src/Interpreters/ActionsDAG.cpp:1637: DB::ActionsDAG::makeConvertingActions(std::vector> const&, std::vector> const&, DB::ActionsDAG::MatchColumnsMode, bool, bool, std::unordered_map, std::equal_to, std::allocator>>*) @ 0x0000000013faa20e 9. /build/src/Interpreters/InterpreterInsertQuery.cpp:620: DB::InterpreterInsertQuery::buildInsertSelectPipeline(DB::ASTInsertQuery&, std::shared_ptr) @ 0x0000000014930b2b 10. /build/src/Interpreters/InterpreterInsertQuery.cpp:870: DB::InterpreterInsertQuery::execute() @ 0x0000000014933e3d 11. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88dc9 12. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 13. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 14. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 15. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 16. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 17. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 18. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 19. ? @ 0x00007fbc6213eac3 20. ? @ 0x00007fbc621d0850 2025.07.28 12:03:43.051039 [ 3968 ] {} test_13.rmt2 (7f9b740d-015c-470e-8cc6-8ba33be0dc63): auto DB::StorageReplicatedMergeTree::processQueueEntry(ReplicatedMergeTreeQueue::SelectedEntryPtr)::(anonymous class)::operator()(LogEntryPtr &) const: Code: 86. DB::HTTPException: Received error from remote server http://146b4357c08d:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Ftest%2F01165%2Ftest_13%2Frmt%2Freplicas%2F1&part=20250728_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.6.10636.altinitytest (altinity build)) '. (RECEIVED_ERROR_FROM_REMOTE_IO_SERVER), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.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 const&, int&&, String const&, unsigned long&&, String const&) @ 0x000000000feda8d9 4. /build/src/IO/HTTPCommon.cpp:104: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x000000000feda6e2 5. /build/src/IO/HTTPCommon.cpp:93: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x000000000feda537 6. /build/src/IO/ReadWriteBufferFromHTTP.cpp:277: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x000000001184a4c4 7. /build/src/IO/ReadWriteBufferFromHTTP.cpp:285: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x000000001184a615 8. /build/src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x000000001184ae59 9. /build/src/IO/ReadWriteBufferFromHTTP.cpp:472: void std::__function::__policy_invoker::__call_impl[abi:se190107]>(std::__function::__policy_storage const*) @ 0x000000001184cedd 10. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001184858b 11. /build/src/IO/ReadWriteBufferFromHTTP.cpp:465: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x000000001184bf0b 12. /build/src/IO/ReadBuffer.h:60: DB::ReadBuffer::next() @ 0x000000000a148c7b 13. /build/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) @ 0x0000000011849fb2 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]>&)>&, 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&) @ 0x0000000011841980 15. /build/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) @ 0x000000001621208e 16. /build/src/Storages/StorageReplicatedMergeTree.cpp:5228: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl[abi:se190107] const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000015f9a5fe 17. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000015ed8bfd 18. /build/src/Storages/StorageReplicatedMergeTree.cpp:2514: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x0000000015ec9aab 19. /build/src/Storages/StorageReplicatedMergeTree.cpp:2349: DB::StorageReplicatedMergeTree::executeLogEntry(DB::ReplicatedMergeTreeLogEntry&) @ 0x0000000015eba91b 20. /build/src/Storages/StorageReplicatedMergeTree.cpp:3876: bool std::__function::__policy_invoker&)>::__call_impl[abi:se190107])::$_1, bool (std::shared_ptr&)>>(std::__function::__policy_storage const*, std::shared_ptr&) @ 0x0000000015f9837e 21. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000165d6fc3 22. /build/src/Storages/StorageReplicatedMergeTree.cpp:3872: DB::StorageReplicatedMergeTree::processQueueEntry(std::shared_ptr) @ 0x0000000015efc18a 23. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001624c1b2 24. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000162f9c70 25. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x00000000162fa55a 26. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc6653 27. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000000fccc4c3 28. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc3d92 29. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fcca080 30. ? @ 0x00007fbc6213eac3 31. ? @ 0x00007fbc621d0850 (version 25.3.6.10636.altinitytest (altinity build)) 2025.07.28 12:03:43.474090 [ 5029 ] {bc358f42-a2e5-4745-8b25-41a7c668eaa2} executeQuery: Code: 349. DB::Exception: Cannot convert NULL value to non-Nullable type: while converting source column src to destination column val: while executing 'FUNCTION _CAST(src :: 0, Int64 :: 1) -> _CAST(src, Int64) Int64 : 2'. (CANNOT_INSERT_NULL_IN_ORDINARY_COLUMN) (version 25.3.6.10636.altinitytest (altinity build)) (from [::1]:35110) (comment: 00690_insert_select_converting_exception_message.sh) (query 1, line 1) (in query: INSERT INTO test_00690 SELECT number % 2 ? 1 : NULL AS src FROM numbers(10) SETTINGS insert_null_as_default=0;), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000000a074fcb 4. /build/src/Functions/FunctionsConversion.h:5877: DB::detail::FunctionCast::prepareRemoveNullable(std::shared_ptr const&, std::shared_ptr const&, bool) 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 @ 0x0000000012f97c88 5. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: COW::immutable_ptr std::__function::__policy_invoker::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)>::__call_impl[abi:se190107] const&, std::shared_ptr const&, bool) 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) @ 0x0000000012f97a8c 6. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000012ddcb1b 7. /build/src/Functions/IFunction.cpp:353: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d93b52 8. /build/src/Functions/IFunction.cpp:424: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d94e1b 9. /build/src/Functions/IFunction.cpp:498: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d95c72 10. /build/src/Interpreters/ExpressionActions.cpp:636: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x00000000145176f3 11. /build/src/Processors/Transforms/ExpressionTransform.cpp:25: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x0000000016c0b34c 12. /build/src/Processors/ISimpleTransform.h:33: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000011a9a453 13. /build/src/Processors/ISimpleTransform.cpp:89: DB::ISimpleTransform::work() @ 0x000000001699fca0 14. /build/src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x00000000169bd00f 15. /build/src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x00000000169b2105 16. /build/src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeSingleThread(unsigned long) @ 0x00000000169b23be 17. /build/src/Processors/Executors/PipelineExecutor.cpp:454: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x00000000169b0be7 18. /build/src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x00000000169b03f4 19. /build/src/Processors/Executors/CompletedPipelineExecutor.cpp:42: void std::__function::__policy_invoker::__call_impl[abi:se190107]::ThreadFromGlobalPoolImpl(DB::CompletedPipelineExecutor::execute()::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169af7e1 20. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc3d92 21. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fcca080 22. ? @ 0x00007fbc6213eac3 23. ? @ 0x00007fbc621d0850 2025.07.28 12:03:43.515180 [ 5029 ] {} TCPHandler: Code: 349. DB::Exception: Cannot convert NULL value to non-Nullable type: while converting source column src to destination column val: while executing 'FUNCTION _CAST(src :: 0, Int64 :: 1) -> _CAST(src, Int64) Int64 : 2'. (CANNOT_INSERT_NULL_IN_ORDINARY_COLUMN), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000000a074fcb 4. /build/src/Functions/FunctionsConversion.h:5877: DB::detail::FunctionCast::prepareRemoveNullable(std::shared_ptr const&, std::shared_ptr const&, bool) 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 @ 0x0000000012f97c88 5. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:149: COW::immutable_ptr std::__function::__policy_invoker::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)>::__call_impl[abi:se190107] const&, std::shared_ptr const&, bool) 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) @ 0x0000000012f97a8c 6. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000012ddcb1b 7. /build/src/Functions/IFunction.cpp:353: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d93b52 8. /build/src/Functions/IFunction.cpp:424: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d94e1b 9. /build/src/Functions/IFunction.cpp:498: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d95c72 10. /build/src/Interpreters/ExpressionActions.cpp:636: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x00000000145176f3 11. /build/src/Processors/Transforms/ExpressionTransform.cpp:25: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x0000000016c0b34c 12. /build/src/Processors/ISimpleTransform.h:33: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000011a9a453 13. /build/src/Processors/ISimpleTransform.cpp:89: DB::ISimpleTransform::work() @ 0x000000001699fca0 14. /build/src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x00000000169bd00f 15. /build/src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x00000000169b2105 16. /build/src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeSingleThread(unsigned long) @ 0x00000000169b23be 17. /build/src/Processors/Executors/PipelineExecutor.cpp:454: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x00000000169b0be7 18. /build/src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x00000000169b03f4 19. /build/src/Processors/Executors/CompletedPipelineExecutor.cpp:42: void std::__function::__policy_invoker::__call_impl[abi:se190107]::ThreadFromGlobalPoolImpl(DB::CompletedPipelineExecutor::execute()::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169af7e1 20. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc3d92 21. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fcca080 22. ? @ 0x00007fbc6213eac3 23. ? @ 0x00007fbc621d0850 Job's origin stack trace: 0. /build/src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000000fc33b84 1. /build/src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000000fcc2ea7 2. /build/src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fcc535c 3. /build/src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000000fcc584d 4. /build/src/Common/ThreadPool.h:279: DB::CompletedPipelineExecutor::execute() @ 0x00000000169af267 5. /build/src/Server/TCPHandler.cpp:707: DB::TCPHandler::runImpl() @ 0x00000000168e6b2e 6. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 7. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 8. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 9. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 10. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 11. ? @ 0x00007fbc6213eac3 12. ? @ 0x00007fbc621d0850 2025.07.28 12:03:43.943927 [ 3965 ] {} test_13.rmt2 (7f9b740d-015c-470e-8cc6-8ba33be0dc63): auto DB::StorageReplicatedMergeTree::processQueueEntry(ReplicatedMergeTreeQueue::SelectedEntryPtr)::(anonymous class)::operator()(LogEntryPtr &) const: Code: 86. DB::HTTPException: Received error from remote server http://146b4357c08d:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Ftest%2F01165%2Ftest_13%2Frmt%2Freplicas%2F1&part=20250728_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.6.10636.altinitytest (altinity build)) '. (RECEIVED_ERROR_FROM_REMOTE_IO_SERVER), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.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 const&, int&&, String const&, unsigned long&&, String const&) @ 0x000000000feda8d9 4. /build/src/IO/HTTPCommon.cpp:104: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x000000000feda6e2 5. /build/src/IO/HTTPCommon.cpp:93: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x000000000feda537 6. /build/src/IO/ReadWriteBufferFromHTTP.cpp:277: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x000000001184a4c4 7. /build/src/IO/ReadWriteBufferFromHTTP.cpp:285: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x000000001184a615 8. /build/src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x000000001184ae59 9. /build/src/IO/ReadWriteBufferFromHTTP.cpp:472: void std::__function::__policy_invoker::__call_impl[abi:se190107]>(std::__function::__policy_storage const*) @ 0x000000001184cedd 10. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001184858b 11. /build/src/IO/ReadWriteBufferFromHTTP.cpp:465: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x000000001184bf0b 12. /build/src/IO/ReadBuffer.h:60: DB::ReadBuffer::next() @ 0x000000000a148c7b 13. /build/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) @ 0x0000000011849fb2 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]>&)>&, 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&) @ 0x0000000011841980 15. /build/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) @ 0x000000001621208e 16. /build/src/Storages/StorageReplicatedMergeTree.cpp:5228: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl[abi:se190107] const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000015f9a5fe 17. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000015ed8bfd 18. /build/src/Storages/StorageReplicatedMergeTree.cpp:2514: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x0000000015ec9aab 19. /build/src/Storages/StorageReplicatedMergeTree.cpp:2349: DB::StorageReplicatedMergeTree::executeLogEntry(DB::ReplicatedMergeTreeLogEntry&) @ 0x0000000015eba91b 20. /build/src/Storages/StorageReplicatedMergeTree.cpp:3876: bool std::__function::__policy_invoker&)>::__call_impl[abi:se190107])::$_1, bool (std::shared_ptr&)>>(std::__function::__policy_storage const*, std::shared_ptr&) @ 0x0000000015f9837e 21. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000165d6fc3 22. /build/src/Storages/StorageReplicatedMergeTree.cpp:3872: DB::StorageReplicatedMergeTree::processQueueEntry(std::shared_ptr) @ 0x0000000015efc18a 23. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001624c1b2 24. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000162f9c70 25. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x00000000162fa55a 26. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc6653 27. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000000fccc4c3 28. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc3d92 29. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fcca080 30. ? @ 0x00007fbc6213eac3 31. ? @ 0x00007fbc621d0850 (version 25.3.6.10636.altinitytest (altinity build)) 2025.07.28 12:03:44.188848 [ 5029 ] {3a2a9c86-b782-46f8-be0f-6aaf14a685be} executeQuery: Code: 42. DB::Exception: Number of arguments for function toMillisecond doesn't match: passed 0, should be 1 or 2: In scope SELECT toMillisecond(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 25.3.6.10636.altinitytest (altinity build)) (from [::1]:35156) (comment: 02998_to_milliseconds.sql) (query 1, line 1) (in query: -- Negative tests SELECT toMillisecond();), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, unsigned long&&) @ 0x000000000a06f86b 4. /build/src/Functions/IFunctionDateOrDateTime.h:68: DB::FunctionDateOrDateTimeBase::checkArguments(std::vector> const&, bool) const @ 0x000000000e81e3b6 5. /build/src/Functions/FunctionDateOrDateTimeToSomething.h:23: DB::FunctionDateOrDateTimeToSomething, DB::ToMillisecondImpl>::getReturnTypeImpl(std::vector> const&) const @ 0x000000000e85acc8 6. /build/src/Functions/IFunction.cpp:645: DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x0000000012d96b0c 7. /build/src/Functions/IFunction.cpp:577: DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x0000000012d9669c 8. /build/src/Functions/IFunction.cpp:606: DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x0000000012d96edc 9. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3544: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000014033cc9 10. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3838: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000014019a9e 11. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3980: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000014018e31 12. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:4304: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000014042fa7 13. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5605: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000014013749 14. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000140127f9 15. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000014011fce 16. /build/src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000001406ce8a 17. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000014973b42 18. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000001497268d 19. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000014974d24 20. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001492924b 21. /build/src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88641 22. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 23. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 24. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 25. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 26. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 27. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 28. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 29. ? @ 0x00007fbc6213eac3 30. ? @ 0x00007fbc621d0850 2025.07.28 12:03:44.201819 [ 5029 ] {} TCPHandler: Code: 42. DB::Exception: Number of arguments for function toMillisecond doesn't match: passed 0, should be 1 or 2: In scope SELECT toMillisecond(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, unsigned long&&) @ 0x000000000a06f86b 4. /build/src/Functions/IFunctionDateOrDateTime.h:68: DB::FunctionDateOrDateTimeBase::checkArguments(std::vector> const&, bool) const @ 0x000000000e81e3b6 5. /build/src/Functions/FunctionDateOrDateTimeToSomething.h:23: DB::FunctionDateOrDateTimeToSomething, DB::ToMillisecondImpl>::getReturnTypeImpl(std::vector> const&) const @ 0x000000000e85acc8 6. /build/src/Functions/IFunction.cpp:645: DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x0000000012d96b0c 7. /build/src/Functions/IFunction.cpp:577: DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x0000000012d9669c 8. /build/src/Functions/IFunction.cpp:606: DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x0000000012d96edc 9. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3544: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000014033cc9 10. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3838: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000014019a9e 11. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3980: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000014018e31 12. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:4304: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000014042fa7 13. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5605: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000014013749 14. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000140127f9 15. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000014011fce 16. /build/src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000001406ce8a 17. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000014973b42 18. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000001497268d 19. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000014974d24 20. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001492924b 21. /build/src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88641 22. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 23. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 24. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 25. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 26. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 27. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 28. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 29. ? @ 0x00007fbc6213eac3 30. ? @ 0x00007fbc621d0850 2025.07.28 12:03:44.251449 [ 5029 ] {b9e71a6d-aa0f-4fb9-bacf-22dabc9b22d8} executeQuery: Code: 43. DB::Exception: Illegal type String of argument of function toMillisecond. Should be Date, Date32, DateTime or DateTime64: In scope SELECT toMillisecond('string'). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.6.10636.altinitytest (altinity build)) (from [::1]:35156) (comment: 02998_to_milliseconds.sql) (query 2, line 3) (in query: SELECT toMillisecond('string');), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000a06a8eb 4. /build/src/Functions/IFunctionDateOrDateTime.h:47: DB::FunctionDateOrDateTimeBase::checkArguments(std::vector> const&, bool) const @ 0x000000000e81e274 5. /build/src/Functions/FunctionDateOrDateTimeToSomething.h:23: DB::FunctionDateOrDateTimeToSomething, DB::ToMillisecondImpl>::getReturnTypeImpl(std::vector> const&) const @ 0x000000000e85acc8 6. /build/src/Functions/IFunction.cpp:645: DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x0000000012d96b0c 7. /build/src/Functions/IFunction.cpp:577: DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x0000000012d9669c 8. /build/src/Functions/IFunction.cpp:606: DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x0000000012d96edc 9. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3544: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000014033cc9 10. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3838: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000014019a9e 11. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3980: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000014018e31 12. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:4304: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000014042fa7 13. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5605: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000014013749 14. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000140127f9 15. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000014011fce 16. /build/src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000001406ce8a 17. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000014973b42 18. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000001497268d 19. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000014974d24 20. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001492924b 21. /build/src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88641 22. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 23. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 24. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 25. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 26. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 27. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 28. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 29. ? @ 0x00007fbc6213eac3 30. ? @ 0x00007fbc621d0850 2025.07.28 12:03:44.259804 [ 5029 ] {} TCPHandler: Code: 43. DB::Exception: Illegal type String of argument of function toMillisecond. Should be Date, Date32, DateTime or DateTime64: In scope SELECT toMillisecond('string'). (ILLEGAL_TYPE_OF_ARGUMENT), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000a06a8eb 4. /build/src/Functions/IFunctionDateOrDateTime.h:47: DB::FunctionDateOrDateTimeBase::checkArguments(std::vector> const&, bool) const @ 0x000000000e81e274 5. /build/src/Functions/FunctionDateOrDateTimeToSomething.h:23: DB::FunctionDateOrDateTimeToSomething, DB::ToMillisecondImpl>::getReturnTypeImpl(std::vector> const&) const @ 0x000000000e85acc8 6. /build/src/Functions/IFunction.cpp:645: DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x0000000012d96b0c 7. /build/src/Functions/IFunction.cpp:577: DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x0000000012d9669c 8. /build/src/Functions/IFunction.cpp:606: DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x0000000012d96edc 9. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3544: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000014033cc9 10. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3838: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000014019a9e 11. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3980: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000014018e31 12. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:4304: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000014042fa7 13. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5605: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000014013749 14. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000140127f9 15. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000014011fce 16. /build/src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000001406ce8a 17. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000014973b42 18. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000001497268d 19. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000014974d24 20. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001492924b 21. /build/src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88641 22. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 23. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 24. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 25. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 26. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 27. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 28. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 29. ? @ 0x00007fbc6213eac3 30. ? @ 0x00007fbc621d0850 2025.07.28 12:03:44.329894 [ 5029 ] {6aa04b5a-161c-4658-bc20-133e42de71f1} executeQuery: Code: 43. DB::Exception: Illegal argument of type Date for function toMillisecond: In scope SELECT toMillisecond(toDate('2024-02-28')). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.6.10636.altinitytest (altinity build)) (from [::1]:35156) (comment: 02998_to_milliseconds.sql) (query 3, line 4) (in query: SELECT toMillisecond(toDate('2024-02-28'));), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type>, char const*&) @ 0x000000000a06d8cb 4. /build/src/Functions/DateTimeTransforms.cpp:13: DB::throwDateIsNotSupported(char const*) @ 0x000000000a06d705 5. /build/src/Functions/DateTimeTransforms.h:1599: COW::immutable_ptr DB::DateTimeTransformImpl, DB::ToMillisecondImpl, false>::execute(std::vector> const&, std::shared_ptr const&, unsigned long, DB::ToMillisecondImpl const&) @ 0x000000000e85af1e 6. /build/src/Functions/FunctionDateOrDateTimeToSomething.h:72: DB::FunctionDateOrDateTimeToSomething, DB::ToMillisecondImpl>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000e85a9a0 7. /build/src/Functions/IFunction.h:437: DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000a069f2a 8. /build/src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000012d9965a 9. /build/src/Functions/IFunction.cpp:351: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d93b02 10. /build/src/Functions/IFunction.cpp:177: DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d93698 11. /build/src/Functions/IFunction.cpp:343: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d93aad 12. /build/src/Functions/IFunction.cpp:420: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d95059 13. /build/src/Functions/IFunction.cpp:498: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d95c72 14. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3567: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000014034494 15. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3838: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000014019a9e 16. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3980: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000014018e31 17. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:4304: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000014042fa7 18. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5605: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000014013749 19. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000140127f9 20. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000014011fce 21. /build/src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000001406ce8a 22. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000014973b42 23. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000001497268d 24. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000014974d24 25. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001492924b 26. /build/src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88641 27. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 28. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 29. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 30. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 31. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 2025.07.28 12:03:44.347695 [ 5029 ] {} TCPHandler: Code: 43. DB::Exception: Illegal argument of type Date for function toMillisecond: In scope SELECT toMillisecond(toDate('2024-02-28')). (ILLEGAL_TYPE_OF_ARGUMENT), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type>, char const*&) @ 0x000000000a06d8cb 4. /build/src/Functions/DateTimeTransforms.cpp:13: DB::throwDateIsNotSupported(char const*) @ 0x000000000a06d705 5. /build/src/Functions/DateTimeTransforms.h:1599: COW::immutable_ptr DB::DateTimeTransformImpl, DB::ToMillisecondImpl, false>::execute(std::vector> const&, std::shared_ptr const&, unsigned long, DB::ToMillisecondImpl const&) @ 0x000000000e85af1e 6. /build/src/Functions/FunctionDateOrDateTimeToSomething.h:72: DB::FunctionDateOrDateTimeToSomething, DB::ToMillisecondImpl>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000e85a9a0 7. /build/src/Functions/IFunction.h:437: DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000a069f2a 8. /build/src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000012d9965a 9. /build/src/Functions/IFunction.cpp:351: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d93b02 10. /build/src/Functions/IFunction.cpp:177: DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d93698 11. /build/src/Functions/IFunction.cpp:343: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d93aad 12. /build/src/Functions/IFunction.cpp:420: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d95059 13. /build/src/Functions/IFunction.cpp:498: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d95c72 14. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3567: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000014034494 15. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3838: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000014019a9e 16. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3980: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000014018e31 17. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:4304: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000014042fa7 18. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5605: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000014013749 19. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000140127f9 20. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000014011fce 21. /build/src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000001406ce8a 22. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000014973b42 23. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000001497268d 24. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000014974d24 25. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001492924b 26. /build/src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88641 27. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 28. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 29. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 30. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 31. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 2025.07.28 12:03:44.480976 [ 5029 ] {218974f2-1a34-4734-b10f-fb9a229f0475} executeQuery: Code: 43. DB::Exception: Illegal argument of type Date32 for function toMillisecond: In scope SELECT toMillisecond(toDate32('2024-02-28')). (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.6.10636.altinitytest (altinity build)) (from [::1]:35156) (comment: 02998_to_milliseconds.sql) (query 4, line 5) (in query: SELECT toMillisecond(toDate32('2024-02-28'));), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type>, char const*&) @ 0x000000000a06d8cb 4. /build/src/Functions/DateTimeTransforms.cpp:18: DB::throwDate32IsNotSupported(char const*) @ 0x000000000a06d7a5 5. /build/src/Functions/DateTimeTransforms.h:1595: COW::immutable_ptr DB::DateTimeTransformImpl, DB::ToMillisecondImpl, false>::execute(std::vector> const&, std::shared_ptr const&, unsigned long, DB::ToMillisecondImpl const&) @ 0x000000000e85b1fe 6. /build/src/Functions/FunctionDateOrDateTimeToSomething.h:74: DB::FunctionDateOrDateTimeToSomething, DB::ToMillisecondImpl>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000e85a9cd 7. /build/src/Functions/IFunction.h:437: DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000a069f2a 8. /build/src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000012d9965a 9. /build/src/Functions/IFunction.cpp:351: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d93b02 10. /build/src/Functions/IFunction.cpp:177: DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d93698 11. /build/src/Functions/IFunction.cpp:343: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d93aad 12. /build/src/Functions/IFunction.cpp:420: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d95059 13. /build/src/Functions/IFunction.cpp:498: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d95c72 14. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3567: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000014034494 15. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3838: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000014019a9e 16. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3980: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000014018e31 17. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:4304: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000014042fa7 18. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5605: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000014013749 19. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000140127f9 20. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000014011fce 21. /build/src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000001406ce8a 22. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000014973b42 23. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000001497268d 24. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000014974d24 25. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001492924b 26. /build/src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88641 27. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 28. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 29. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 30. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 31. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 2025.07.28 12:03:44.507281 [ 5029 ] {} TCPHandler: Code: 43. DB::Exception: Illegal argument of type Date32 for function toMillisecond: In scope SELECT toMillisecond(toDate32('2024-02-28')). (ILLEGAL_TYPE_OF_ARGUMENT), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type>, char const*&) @ 0x000000000a06d8cb 4. /build/src/Functions/DateTimeTransforms.cpp:18: DB::throwDate32IsNotSupported(char const*) @ 0x000000000a06d7a5 5. /build/src/Functions/DateTimeTransforms.h:1595: COW::immutable_ptr DB::DateTimeTransformImpl, DB::ToMillisecondImpl, false>::execute(std::vector> const&, std::shared_ptr const&, unsigned long, DB::ToMillisecondImpl const&) @ 0x000000000e85b1fe 6. /build/src/Functions/FunctionDateOrDateTimeToSomething.h:74: DB::FunctionDateOrDateTimeToSomething, DB::ToMillisecondImpl>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000e85a9cd 7. /build/src/Functions/IFunction.h:437: DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000a069f2a 8. /build/src/Functions/IFunctionAdaptors.cpp:16: DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000012d9965a 9. /build/src/Functions/IFunction.cpp:351: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d93b02 10. /build/src/Functions/IFunction.cpp:177: DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d93698 11. /build/src/Functions/IFunction.cpp:343: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d93aad 12. /build/src/Functions/IFunction.cpp:420: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d95059 13. /build/src/Functions/IFunction.cpp:498: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d95c72 14. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3567: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000014034494 15. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3838: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000014019a9e 16. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3980: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000014018e31 17. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:4304: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000014042fa7 18. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5605: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000014013749 19. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000140127f9 20. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000014011fce 21. /build/src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000001406ce8a 22. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000014973b42 23. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000001497268d 24. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000014974d24 25. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001492924b 26. /build/src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88641 27. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 28. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 29. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 30. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 31. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 2025.07.28 12:03:44.661345 [ 3971 ] {} test_13.rmt2 (7f9b740d-015c-470e-8cc6-8ba33be0dc63): auto DB::StorageReplicatedMergeTree::processQueueEntry(ReplicatedMergeTreeQueue::SelectedEntryPtr)::(anonymous class)::operator()(LogEntryPtr &) const: Code: 86. DB::HTTPException: Received error from remote server http://146b4357c08d:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Ftest%2F01165%2Ftest_13%2Frmt%2Freplicas%2F1&part=20250728_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.6.10636.altinitytest (altinity build)) '. (RECEIVED_ERROR_FROM_REMOTE_IO_SERVER), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.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 const&, int&&, String const&, unsigned long&&, String const&) @ 0x000000000feda8d9 4. /build/src/IO/HTTPCommon.cpp:104: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x000000000feda6e2 5. /build/src/IO/HTTPCommon.cpp:93: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x000000000feda537 6. /build/src/IO/ReadWriteBufferFromHTTP.cpp:277: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x000000001184a4c4 7. /build/src/IO/ReadWriteBufferFromHTTP.cpp:285: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x000000001184a615 8. /build/src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x000000001184ae59 9. /build/src/IO/ReadWriteBufferFromHTTP.cpp:472: void std::__function::__policy_invoker::__call_impl[abi:se190107]>(std::__function::__policy_storage const*) @ 0x000000001184cedd 10. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001184858b 11. /build/src/IO/ReadWriteBufferFromHTTP.cpp:465: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x000000001184bf0b 12. /build/src/IO/ReadBuffer.h:60: DB::ReadBuffer::next() @ 0x000000000a148c7b 13. /build/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) @ 0x0000000011849fb2 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]>&)>&, 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&) @ 0x0000000011841980 15. /build/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) @ 0x000000001621208e 16. /build/src/Storages/StorageReplicatedMergeTree.cpp:5228: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl[abi:se190107] const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000015f9a5fe 17. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000015ed8bfd 18. /build/src/Storages/StorageReplicatedMergeTree.cpp:2514: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x0000000015ec9aab 19. /build/src/Storages/StorageReplicatedMergeTree.cpp:2349: DB::StorageReplicatedMergeTree::executeLogEntry(DB::ReplicatedMergeTreeLogEntry&) @ 0x0000000015eba91b 20. /build/src/Storages/StorageReplicatedMergeTree.cpp:3876: bool std::__function::__policy_invoker&)>::__call_impl[abi:se190107])::$_1, bool (std::shared_ptr&)>>(std::__function::__policy_storage const*, std::shared_ptr&) @ 0x0000000015f9837e 21. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000165d6fc3 22. /build/src/Storages/StorageReplicatedMergeTree.cpp:3872: DB::StorageReplicatedMergeTree::processQueueEntry(std::shared_ptr) @ 0x0000000015efc18a 23. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001624c1b2 24. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000162f9c70 25. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x00000000162fa55a 26. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc6653 27. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000000fccc4c3 28. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc3d92 29. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fcca080 30. ? @ 0x00007fbc6213eac3 31. ? @ 0x00007fbc621d0850 (version 25.3.6.10636.altinitytest (altinity build)) 2025.07.28 12:03:45.244896 [ 3963 ] {} test_13.rmt2 (7f9b740d-015c-470e-8cc6-8ba33be0dc63): auto DB::StorageReplicatedMergeTree::processQueueEntry(ReplicatedMergeTreeQueue::SelectedEntryPtr)::(anonymous class)::operator()(LogEntryPtr &) const: Code: 86. DB::HTTPException: Received error from remote server http://146b4357c08d:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Ftest%2F01165%2Ftest_13%2Frmt%2Freplicas%2F1&part=20250728_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.6.10636.altinitytest (altinity build)) '. (RECEIVED_ERROR_FROM_REMOTE_IO_SERVER), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.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 const&, int&&, String const&, unsigned long&&, String const&) @ 0x000000000feda8d9 4. /build/src/IO/HTTPCommon.cpp:104: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x000000000feda6e2 5. /build/src/IO/HTTPCommon.cpp:93: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x000000000feda537 6. /build/src/IO/ReadWriteBufferFromHTTP.cpp:277: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x000000001184a4c4 7. /build/src/IO/ReadWriteBufferFromHTTP.cpp:285: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x000000001184a615 8. /build/src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x000000001184ae59 9. /build/src/IO/ReadWriteBufferFromHTTP.cpp:472: void std::__function::__policy_invoker::__call_impl[abi:se190107]>(std::__function::__policy_storage const*) @ 0x000000001184cedd 10. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001184858b 11. /build/src/IO/ReadWriteBufferFromHTTP.cpp:465: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x000000001184bf0b 12. /build/src/IO/ReadBuffer.h:60: DB::ReadBuffer::next() @ 0x000000000a148c7b 13. /build/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) @ 0x0000000011849fb2 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]>&)>&, 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&) @ 0x0000000011841980 15. /build/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) @ 0x000000001621208e 16. /build/src/Storages/StorageReplicatedMergeTree.cpp:5228: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl[abi:se190107] const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000015f9a5fe 17. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000015ed8bfd 18. /build/src/Storages/StorageReplicatedMergeTree.cpp:2514: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x0000000015ec9aab 19. /build/src/Storages/StorageReplicatedMergeTree.cpp:2349: DB::StorageReplicatedMergeTree::executeLogEntry(DB::ReplicatedMergeTreeLogEntry&) @ 0x0000000015eba91b 20. /build/src/Storages/StorageReplicatedMergeTree.cpp:3876: bool std::__function::__policy_invoker&)>::__call_impl[abi:se190107])::$_1, bool (std::shared_ptr&)>>(std::__function::__policy_storage const*, std::shared_ptr&) @ 0x0000000015f9837e 21. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000165d6fc3 22. /build/src/Storages/StorageReplicatedMergeTree.cpp:3872: DB::StorageReplicatedMergeTree::processQueueEntry(std::shared_ptr) @ 0x0000000015efc18a 23. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001624c1b2 24. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000162f9c70 25. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x00000000162fa55a 26. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc6653 27. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000000fccc4c3 28. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc3d92 29. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fcca080 30. ? @ 0x00007fbc6213eac3 31. ? @ 0x00007fbc621d0850 (version 25.3.6.10636.altinitytest (altinity build)) 2025.07.28 12:03:45.838555 [ 4900 ] {28f41169-8511-4655-8c44-7db04a9aa0ad} executeQuery: Code: 36. DB::Exception: Unsupported aggregate function count, supported functions are any,anyLast,min,max,sum,sumWithOverflow,groupBitAnd,groupBitOr,groupBitXor,sumMap,minMap,maxMap,groupArrayArray,groupArrayLastArray,groupUniqArrayArray,groupUniqArrayArrayMap,sumMappedArrays,minMappedArrays,maxMappedArrays. (BAD_ARGUMENTS) (version 25.3.6.10636.altinitytest (altinity build)) (from [::1]:35112) (comment: 01570_aggregator_combinator_simple_state.sql) (query 15, line 17) (in query: -- non-SimpleAggregateFunction with countSimpleState(number) as c select toTypeName(c), c from numbers(1);), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000a06a8eb 4. /build/src/DataTypes/DataTypeCustomSimpleAggregateFunction.cpp:59: DB::DataTypeCustomSimpleAggregateFunction::checkSupportedFunctions(std::shared_ptr const&) @ 0x0000000013bda0f6 5. /build/src/AggregateFunctions/Combinators/AggregateFunctionSimpleState.h:32: DB::AggregateFunctionSimpleState::createResultType(std::shared_ptr const&, DB::Array const&) @ 0x00000000117e975c 6. /build/src/AggregateFunctions/Combinators/AggregateFunctionSimpleState.h:23: DB::AggregateFunctionSimpleState::AggregateFunctionSimpleState(std::shared_ptr, std::vector, std::allocator>> const&, DB::Array const&) @ 0x00000000117e9646 7. /build/contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: std::shared_ptr std::allocate_shared[abi:se190107], std::shared_ptr const&, std::vector, std::allocator>> const&, DB::Array const&, 0>(std::allocator const&, std::shared_ptr const&, std::vector, std::allocator>> const&, DB::Array const&) @ 0x00000000117ff7d8 8. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:851: DB::(anonymous namespace)::AggregateFunctionCombinatorSimpleState::transformAggregateFunction(std::shared_ptr const&, DB::AggregateFunctionProperties const&, std::vector, std::allocator>> const&, DB::Array const&) const @ 0x00000000117ff751 9. /build/src/AggregateFunctions/AggregateFunctionFactory.cpp:260: DB::AggregateFunctionFactory::getImpl(String const&, DB::NullsAction, std::vector, std::allocator>> const&, DB::Array const&, DB::AggregateFunctionProperties&, bool) const @ 0x00000000131e02f6 10. /build/src/AggregateFunctions/AggregateFunctionFactory.cpp:130: DB::AggregateFunctionFactory::get(String const&, DB::NullsAction, std::vector, std::allocator>> const&, DB::Array const&, DB::AggregateFunctionProperties&) const @ 0x00000000131df0ca 11. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3368: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000014032fed 12. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3838: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000014019a9e 13. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:1242: DB::QueryAnalyzer::tryResolveIdentifierFromAliases(DB::IdentifierLookup const&, DB::IdentifierResolveScope&, DB::IdentifierResolveContext) @ 0x0000000014028693 14. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:1493: DB::QueryAnalyzer::tryResolveIdentifier(DB::IdentifierLookup const&, DB::IdentifierResolveScope&, DB::IdentifierResolveContext) @ 0x000000001402950d 15. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3692: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000001401a2b4 16. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3980: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000014018e31 17. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:2925: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000001402fcbd 18. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3838: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000014019a9e 19. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3980: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000014018e31 20. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:4304: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000014042fa7 21. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5605: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000014013749 22. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000140127f9 23. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000014011fce 24. /build/src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000001406ce8a 25. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000014973b42 26. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000001497268d 27. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000014974d24 28. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001492924b 29. /build/src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88641 30. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 31. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 2025.07.28 12:03:45.841080 [ 4900 ] {} TCPHandler: Code: 36. DB::Exception: Unsupported aggregate function count, supported functions are any,anyLast,min,max,sum,sumWithOverflow,groupBitAnd,groupBitOr,groupBitXor,sumMap,minMap,maxMap,groupArrayArray,groupArrayLastArray,groupUniqArrayArray,groupUniqArrayArrayMap,sumMappedArrays,minMappedArrays,maxMappedArrays. (BAD_ARGUMENTS), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000a06a8eb 4. /build/src/DataTypes/DataTypeCustomSimpleAggregateFunction.cpp:59: DB::DataTypeCustomSimpleAggregateFunction::checkSupportedFunctions(std::shared_ptr const&) @ 0x0000000013bda0f6 5. /build/src/AggregateFunctions/Combinators/AggregateFunctionSimpleState.h:32: DB::AggregateFunctionSimpleState::createResultType(std::shared_ptr const&, DB::Array const&) @ 0x00000000117e975c 6. /build/src/AggregateFunctions/Combinators/AggregateFunctionSimpleState.h:23: DB::AggregateFunctionSimpleState::AggregateFunctionSimpleState(std::shared_ptr, std::vector, std::allocator>> const&, DB::Array const&) @ 0x00000000117e9646 7. /build/contrib/llvm-project/libcxx/include/__memory/construct_at.h:41: std::shared_ptr std::allocate_shared[abi:se190107], std::shared_ptr const&, std::vector, std::allocator>> const&, DB::Array const&, 0>(std::allocator const&, std::shared_ptr const&, std::vector, std::allocator>> const&, DB::Array const&) @ 0x00000000117ff7d8 8. /build/contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:851: DB::(anonymous namespace)::AggregateFunctionCombinatorSimpleState::transformAggregateFunction(std::shared_ptr const&, DB::AggregateFunctionProperties const&, std::vector, std::allocator>> const&, DB::Array const&) const @ 0x00000000117ff751 9. /build/src/AggregateFunctions/AggregateFunctionFactory.cpp:260: DB::AggregateFunctionFactory::getImpl(String const&, DB::NullsAction, std::vector, std::allocator>> const&, DB::Array const&, DB::AggregateFunctionProperties&, bool) const @ 0x00000000131e02f6 10. /build/src/AggregateFunctions/AggregateFunctionFactory.cpp:130: DB::AggregateFunctionFactory::get(String const&, DB::NullsAction, std::vector, std::allocator>> const&, DB::Array const&, DB::AggregateFunctionProperties&) const @ 0x00000000131df0ca 11. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3368: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000014032fed 12. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3838: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000014019a9e 13. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:1242: DB::QueryAnalyzer::tryResolveIdentifierFromAliases(DB::IdentifierLookup const&, DB::IdentifierResolveScope&, DB::IdentifierResolveContext) @ 0x0000000014028693 14. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:1493: DB::QueryAnalyzer::tryResolveIdentifier(DB::IdentifierLookup const&, DB::IdentifierResolveScope&, DB::IdentifierResolveContext) @ 0x000000001402950d 15. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3692: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000001401a2b4 16. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3980: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000014018e31 17. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:2925: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000001402fcbd 18. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3838: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000014019a9e 19. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:3980: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000014018e31 20. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:4304: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000014042fa7 21. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5605: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000014013749 22. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000140127f9 23. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000014011fce 24. /build/src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000001406ce8a 25. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000014973b42 26. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000001497268d 27. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000014974d24 28. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001492924b 29. /build/src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88641 30. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 31. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 2025.07.28 12:03:46.165823 [ 3974 ] {} test_13.rmt2 (7f9b740d-015c-470e-8cc6-8ba33be0dc63): auto DB::StorageReplicatedMergeTree::processQueueEntry(ReplicatedMergeTreeQueue::SelectedEntryPtr)::(anonymous class)::operator()(LogEntryPtr &) const: Code: 86. DB::HTTPException: Received error from remote server http://146b4357c08d:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Ftest%2F01165%2Ftest_13%2Frmt%2Freplicas%2F1&part=20250728_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.6.10636.altinitytest (altinity build)) '. (RECEIVED_ERROR_FROM_REMOTE_IO_SERVER), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.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 const&, int&&, String const&, unsigned long&&, String const&) @ 0x000000000feda8d9 4. /build/src/IO/HTTPCommon.cpp:104: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x000000000feda6e2 5. /build/src/IO/HTTPCommon.cpp:93: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x000000000feda537 6. /build/src/IO/ReadWriteBufferFromHTTP.cpp:277: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x000000001184a4c4 7. /build/src/IO/ReadWriteBufferFromHTTP.cpp:285: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x000000001184a615 8. /build/src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x000000001184ae59 9. /build/src/IO/ReadWriteBufferFromHTTP.cpp:472: void std::__function::__policy_invoker::__call_impl[abi:se190107]>(std::__function::__policy_storage const*) @ 0x000000001184cedd 10. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001184858b 11. /build/src/IO/ReadWriteBufferFromHTTP.cpp:465: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x000000001184bf0b 12. /build/src/IO/ReadBuffer.h:60: DB::ReadBuffer::next() @ 0x000000000a148c7b 13. /build/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) @ 0x0000000011849fb2 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]>&)>&, 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&) @ 0x0000000011841980 15. /build/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) @ 0x000000001621208e 16. /build/src/Storages/StorageReplicatedMergeTree.cpp:5228: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl[abi:se190107] const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000015f9a5fe 17. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000015ed8bfd 18. /build/src/Storages/StorageReplicatedMergeTree.cpp:2514: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x0000000015ec9aab 19. /build/src/Storages/StorageReplicatedMergeTree.cpp:2349: DB::StorageReplicatedMergeTree::executeLogEntry(DB::ReplicatedMergeTreeLogEntry&) @ 0x0000000015eba91b 20. /build/src/Storages/StorageReplicatedMergeTree.cpp:3876: bool std::__function::__policy_invoker&)>::__call_impl[abi:se190107])::$_1, bool (std::shared_ptr&)>>(std::__function::__policy_storage const*, std::shared_ptr&) @ 0x0000000015f9837e 21. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000165d6fc3 22. /build/src/Storages/StorageReplicatedMergeTree.cpp:3872: DB::StorageReplicatedMergeTree::processQueueEntry(std::shared_ptr) @ 0x0000000015efc18a 23. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001624c1b2 24. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000162f9c70 25. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x00000000162fa55a 26. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc6653 27. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000000fccc4c3 28. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc3d92 29. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fcca080 30. ? @ 0x00007fbc6213eac3 31. ? @ 0x00007fbc621d0850 (version 25.3.6.10636.altinitytest (altinity build)) 2025.07.28 12:03:46.552924 [ 3976 ] {} test_13.rmt2 (7f9b740d-015c-470e-8cc6-8ba33be0dc63): auto DB::StorageReplicatedMergeTree::processQueueEntry(ReplicatedMergeTreeQueue::SelectedEntryPtr)::(anonymous class)::operator()(LogEntryPtr &) const: Code: 86. DB::HTTPException: Received error from remote server http://146b4357c08d:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Ftest%2F01165%2Ftest_13%2Frmt%2Freplicas%2F1&part=20250728_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.6.10636.altinitytest (altinity build)) '. (RECEIVED_ERROR_FROM_REMOTE_IO_SERVER), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.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 const&, int&&, String const&, unsigned long&&, String const&) @ 0x000000000feda8d9 4. /build/src/IO/HTTPCommon.cpp:104: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x000000000feda6e2 5. /build/src/IO/HTTPCommon.cpp:93: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x000000000feda537 6. /build/src/IO/ReadWriteBufferFromHTTP.cpp:277: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x000000001184a4c4 7. /build/src/IO/ReadWriteBufferFromHTTP.cpp:285: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x000000001184a615 8. /build/src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x000000001184ae59 9. /build/src/IO/ReadWriteBufferFromHTTP.cpp:472: void std::__function::__policy_invoker::__call_impl[abi:se190107]>(std::__function::__policy_storage const*) @ 0x000000001184cedd 10. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001184858b 11. /build/src/IO/ReadWriteBufferFromHTTP.cpp:465: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x000000001184bf0b 12. /build/src/IO/ReadBuffer.h:60: DB::ReadBuffer::next() @ 0x000000000a148c7b 13. /build/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) @ 0x0000000011849fb2 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]>&)>&, 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&) @ 0x0000000011841980 15. /build/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) @ 0x000000001621208e 16. /build/src/Storages/StorageReplicatedMergeTree.cpp:5228: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl[abi:se190107] const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000015f9a5fe 17. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000015ed8bfd 18. /build/src/Storages/StorageReplicatedMergeTree.cpp:2514: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x0000000015ec9aab 19. /build/src/Storages/StorageReplicatedMergeTree.cpp:2349: DB::StorageReplicatedMergeTree::executeLogEntry(DB::ReplicatedMergeTreeLogEntry&) @ 0x0000000015eba91b 20. /build/src/Storages/StorageReplicatedMergeTree.cpp:3876: bool std::__function::__policy_invoker&)>::__call_impl[abi:se190107])::$_1, bool (std::shared_ptr&)>>(std::__function::__policy_storage const*, std::shared_ptr&) @ 0x0000000015f9837e 21. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000165d6fc3 22. /build/src/Storages/StorageReplicatedMergeTree.cpp:3872: DB::StorageReplicatedMergeTree::processQueueEntry(std::shared_ptr) @ 0x0000000015efc18a 23. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001624c1b2 24. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000162f9c70 25. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x00000000162fa55a 26. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc6653 27. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000000fccc4c3 28. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc3d92 29. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fcca080 30. ? @ 0x00007fbc6213eac3 31. ? @ 0x00007fbc621d0850 (version 25.3.6.10636.altinitytest (altinity build)) 2025.07.28 12:03:47.149064 [ 3970 ] {} test_13.rmt2 (7f9b740d-015c-470e-8cc6-8ba33be0dc63): auto DB::StorageReplicatedMergeTree::processQueueEntry(ReplicatedMergeTreeQueue::SelectedEntryPtr)::(anonymous class)::operator()(LogEntryPtr &) const: Code: 86. DB::HTTPException: Received error from remote server http://146b4357c08d:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Ftest%2F01165%2Ftest_13%2Frmt%2Freplicas%2F1&part=20250728_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.6.10636.altinitytest (altinity build)) '. (RECEIVED_ERROR_FROM_REMOTE_IO_SERVER), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.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 const&, int&&, String const&, unsigned long&&, String const&) @ 0x000000000feda8d9 4. /build/src/IO/HTTPCommon.cpp:104: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x000000000feda6e2 5. /build/src/IO/HTTPCommon.cpp:93: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x000000000feda537 6. /build/src/IO/ReadWriteBufferFromHTTP.cpp:277: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x000000001184a4c4 7. /build/src/IO/ReadWriteBufferFromHTTP.cpp:285: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x000000001184a615 8. /build/src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x000000001184ae59 9. /build/src/IO/ReadWriteBufferFromHTTP.cpp:472: void std::__function::__policy_invoker::__call_impl[abi:se190107]>(std::__function::__policy_storage const*) @ 0x000000001184cedd 10. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001184858b 11. /build/src/IO/ReadWriteBufferFromHTTP.cpp:465: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x000000001184bf0b 12. /build/src/IO/ReadBuffer.h:60: DB::ReadBuffer::next() @ 0x000000000a148c7b 13. /build/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) @ 0x0000000011849fb2 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]>&)>&, 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&) @ 0x0000000011841980 15. /build/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) @ 0x000000001621208e 16. /build/src/Storages/StorageReplicatedMergeTree.cpp:5228: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl[abi:se190107] const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000015f9a5fe 17. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000015ed8bfd 18. /build/src/Storages/StorageReplicatedMergeTree.cpp:2514: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x0000000015ec9aab 19. /build/src/Storages/StorageReplicatedMergeTree.cpp:2349: DB::StorageReplicatedMergeTree::executeLogEntry(DB::ReplicatedMergeTreeLogEntry&) @ 0x0000000015eba91b 20. /build/src/Storages/StorageReplicatedMergeTree.cpp:3876: bool std::__function::__policy_invoker&)>::__call_impl[abi:se190107])::$_1, bool (std::shared_ptr&)>>(std::__function::__policy_storage const*, std::shared_ptr&) @ 0x0000000015f9837e 21. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000165d6fc3 22. /build/src/Storages/StorageReplicatedMergeTree.cpp:3872: DB::StorageReplicatedMergeTree::processQueueEntry(std::shared_ptr) @ 0x0000000015efc18a 23. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001624c1b2 24. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000162f9c70 25. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x00000000162fa55a 26. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc6653 27. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000000fccc4c3 28. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc3d92 29. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fcca080 30. ? @ 0x00007fbc6213eac3 31. ? @ 0x00007fbc621d0850 (version 25.3.6.10636.altinitytest (altinity build)) 2025.07.28 12:03:48.062321 [ 3967 ] {} test_13.rmt2 (7f9b740d-015c-470e-8cc6-8ba33be0dc63): auto DB::StorageReplicatedMergeTree::processQueueEntry(ReplicatedMergeTreeQueue::SelectedEntryPtr)::(anonymous class)::operator()(LogEntryPtr &) const: Code: 86. DB::HTTPException: Received error from remote server http://146b4357c08d:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Ftest%2F01165%2Ftest_13%2Frmt%2Freplicas%2F1&part=20250728_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.6.10636.altinitytest (altinity build)) '. (RECEIVED_ERROR_FROM_REMOTE_IO_SERVER), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.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 const&, int&&, String const&, unsigned long&&, String const&) @ 0x000000000feda8d9 4. /build/src/IO/HTTPCommon.cpp:104: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x000000000feda6e2 5. /build/src/IO/HTTPCommon.cpp:93: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x000000000feda537 6. /build/src/IO/ReadWriteBufferFromHTTP.cpp:277: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x000000001184a4c4 7. /build/src/IO/ReadWriteBufferFromHTTP.cpp:285: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x000000001184a615 8. /build/src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x000000001184ae59 9. /build/src/IO/ReadWriteBufferFromHTTP.cpp:472: void std::__function::__policy_invoker::__call_impl[abi:se190107]>(std::__function::__policy_storage const*) @ 0x000000001184cedd 10. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001184858b 11. /build/src/IO/ReadWriteBufferFromHTTP.cpp:465: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x000000001184bf0b 12. /build/src/IO/ReadBuffer.h:60: DB::ReadBuffer::next() @ 0x000000000a148c7b 13. /build/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) @ 0x0000000011849fb2 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]>&)>&, 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&) @ 0x0000000011841980 15. /build/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) @ 0x000000001621208e 16. /build/src/Storages/StorageReplicatedMergeTree.cpp:5228: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl[abi:se190107] const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000015f9a5fe 17. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000015ed8bfd 18. /build/src/Storages/StorageReplicatedMergeTree.cpp:2514: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x0000000015ec9aab 19. /build/src/Storages/StorageReplicatedMergeTree.cpp:2349: DB::StorageReplicatedMergeTree::executeLogEntry(DB::ReplicatedMergeTreeLogEntry&) @ 0x0000000015eba91b 20. /build/src/Storages/StorageReplicatedMergeTree.cpp:3876: bool std::__function::__policy_invoker&)>::__call_impl[abi:se190107])::$_1, bool (std::shared_ptr&)>>(std::__function::__policy_storage const*, std::shared_ptr&) @ 0x0000000015f9837e 21. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000165d6fc3 22. /build/src/Storages/StorageReplicatedMergeTree.cpp:3872: DB::StorageReplicatedMergeTree::processQueueEntry(std::shared_ptr) @ 0x0000000015efc18a 23. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001624c1b2 24. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000162f9c70 25. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x00000000162fa55a 26. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc6653 27. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000000fccc4c3 28. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc3d92 29. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fcca080 30. ? @ 0x00007fbc6213eac3 31. ? @ 0x00007fbc621d0850 (version 25.3.6.10636.altinitytest (altinity build)) 2025.07.28 12:03:48.304910 [ 62065 ] {c0c3bab3-e556-415e-a5f5-a357e01a0e76} executeQuery: Code: 43. DB::Exception: Illegal argument of type Date32 for function toHour: while executing 'FUNCTION toHour(__table1.x1 :: 1) -> toHour(__table1.x1) UInt8 : 0'. (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.6.10636.altinitytest (altinity build)) (from [::1]:35182) (comment: 01921_datatype_date32.sql) (query 18, line 20) (in query: select toHour(x1) from t1;), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type>, char const*&) @ 0x000000000a06d8cb 4. /build/src/Functions/DateTimeTransforms.cpp:18: DB::throwDate32IsNotSupported(char const*) @ 0x000000000a06d7a5 5. /build/src/Functions/DateTimeTransforms.h:1482: COW::immutable_ptr DB::DateTimeTransformImpl, DB::ToHourImpl, false>::execute(std::vector> const&, std::shared_ptr const&, unsigned long, DB::ToHourImpl const&) @ 0x000000000e85199e 6. /build/src/Functions/FunctionDateOrDateTimeToSomething.h:74: DB::FunctionDateOrDateTimeToSomething, DB::ToHourImpl>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000e850e2d 7. /build/src/Functions/IFunctionAdaptors.cpp:10: DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000012d995fa 8. /build/src/Functions/IFunction.cpp:353: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d93b52 9. /build/src/Functions/IFunction.cpp:420: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d95059 10. /build/src/Functions/IFunction.cpp:498: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d95c72 11. /build/src/Interpreters/ExpressionActions.cpp:636: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x00000000145176f3 12. /build/src/Processors/Transforms/ExpressionTransform.cpp:25: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x0000000016c0b34c 13. /build/src/Processors/ISimpleTransform.h:33: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000011a9a453 14. /build/src/Processors/ISimpleTransform.cpp:89: DB::ISimpleTransform::work() @ 0x000000001699fca0 15. /build/src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x00000000169bd00f 16. /build/src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x00000000169b2105 17. /build/src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeSingleThread(unsigned long) @ 0x00000000169b23be 18. /build/src/Processors/Executors/PipelineExecutor.cpp:454: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x00000000169b0be7 19. /build/src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x00000000169b03f4 20. /build/src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:se190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169bfeab 21. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc3d92 22. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fcca080 23. ? @ 0x00007fbc6213eac3 24. ? @ 0x00007fbc621d0850 2025.07.28 12:03:48.311747 [ 62065 ] {} TCPHandler: Code: 43. DB::Exception: Illegal argument of type Date32 for function toHour: while executing 'FUNCTION toHour(__table1.x1 :: 1) -> toHour(__table1.x1) UInt8 : 0'. (ILLEGAL_TYPE_OF_ARGUMENT), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type>, char const*&) @ 0x000000000a06d8cb 4. /build/src/Functions/DateTimeTransforms.cpp:18: DB::throwDate32IsNotSupported(char const*) @ 0x000000000a06d7a5 5. /build/src/Functions/DateTimeTransforms.h:1482: COW::immutable_ptr DB::DateTimeTransformImpl, DB::ToHourImpl, false>::execute(std::vector> const&, std::shared_ptr const&, unsigned long, DB::ToHourImpl const&) @ 0x000000000e85199e 6. /build/src/Functions/FunctionDateOrDateTimeToSomething.h:74: DB::FunctionDateOrDateTimeToSomething, DB::ToHourImpl>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000e850e2d 7. /build/src/Functions/IFunctionAdaptors.cpp:10: DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000012d995fa 8. /build/src/Functions/IFunction.cpp:353: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d93b52 9. /build/src/Functions/IFunction.cpp:420: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d95059 10. /build/src/Functions/IFunction.cpp:498: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d95c72 11. /build/src/Interpreters/ExpressionActions.cpp:636: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x00000000145176f3 12. /build/src/Processors/Transforms/ExpressionTransform.cpp:25: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x0000000016c0b34c 13. /build/src/Processors/ISimpleTransform.h:33: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000011a9a453 14. /build/src/Processors/ISimpleTransform.cpp:89: DB::ISimpleTransform::work() @ 0x000000001699fca0 15. /build/src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x00000000169bd00f 16. /build/src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x00000000169b2105 17. /build/src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeSingleThread(unsigned long) @ 0x00000000169b23be 18. /build/src/Processors/Executors/PipelineExecutor.cpp:454: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x00000000169b0be7 19. /build/src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x00000000169b03f4 20. /build/src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:se190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169bfeab 21. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc3d92 22. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fcca080 23. ? @ 0x00007fbc6213eac3 24. ? @ 0x00007fbc621d0850 Job's origin stack trace: 0. /build/src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000000fc33b84 1. /build/src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000000fcc2ea7 2. /build/src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fcc535c 3. /build/src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000000fcc584d 4. /build/src/Common/ThreadPool.h:279: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x00000000169bf193 5. /build/src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x00000000169bf518 6. /build/src/Server/TCPHandler.cpp:1237: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x00000000168f1525 7. /build/src/Server/TCPHandler.cpp:678: DB::TCPHandler::runImpl() @ 0x00000000168e68e5 8. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 9. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 10. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 11. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 12. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 13. ? @ 0x00007fbc6213eac3 14. ? @ 0x00007fbc621d0850 2025.07.28 12:03:48.514404 [ 3970 ] {} test_13.rmt2 (7f9b740d-015c-470e-8cc6-8ba33be0dc63): auto DB::StorageReplicatedMergeTree::processQueueEntry(ReplicatedMergeTreeQueue::SelectedEntryPtr)::(anonymous class)::operator()(LogEntryPtr &) const: Code: 86. DB::HTTPException: Received error from remote server http://146b4357c08d:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Ftest%2F01165%2Ftest_13%2Frmt%2Freplicas%2F1&part=20250728_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.6.10636.altinitytest (altinity build)) '. (RECEIVED_ERROR_FROM_REMOTE_IO_SERVER), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.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 const&, int&&, String const&, unsigned long&&, String const&) @ 0x000000000feda8d9 4. /build/src/IO/HTTPCommon.cpp:104: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x000000000feda6e2 5. /build/src/IO/HTTPCommon.cpp:93: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x000000000feda537 6. /build/src/IO/ReadWriteBufferFromHTTP.cpp:277: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x000000001184a4c4 7. /build/src/IO/ReadWriteBufferFromHTTP.cpp:285: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x000000001184a615 8. /build/src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x000000001184ae59 9. /build/src/IO/ReadWriteBufferFromHTTP.cpp:472: void std::__function::__policy_invoker::__call_impl[abi:se190107]>(std::__function::__policy_storage const*) @ 0x000000001184cedd 10. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001184858b 11. /build/src/IO/ReadWriteBufferFromHTTP.cpp:465: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x000000001184bf0b 12. /build/src/IO/ReadBuffer.h:60: DB::ReadBuffer::next() @ 0x000000000a148c7b 13. /build/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) @ 0x0000000011849fb2 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]>&)>&, 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&) @ 0x0000000011841980 15. /build/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) @ 0x000000001621208e 16. /build/src/Storages/StorageReplicatedMergeTree.cpp:5228: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl[abi:se190107] const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000015f9a5fe 17. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000015ed8bfd 18. /build/src/Storages/StorageReplicatedMergeTree.cpp:2514: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x0000000015ec9aab 19. /build/src/Storages/StorageReplicatedMergeTree.cpp:2349: DB::StorageReplicatedMergeTree::executeLogEntry(DB::ReplicatedMergeTreeLogEntry&) @ 0x0000000015eba91b 20. /build/src/Storages/StorageReplicatedMergeTree.cpp:3876: bool std::__function::__policy_invoker&)>::__call_impl[abi:se190107])::$_1, bool (std::shared_ptr&)>>(std::__function::__policy_storage const*, std::shared_ptr&) @ 0x0000000015f9837e 21. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000165d6fc3 22. /build/src/Storages/StorageReplicatedMergeTree.cpp:3872: DB::StorageReplicatedMergeTree::processQueueEntry(std::shared_ptr) @ 0x0000000015efc18a 23. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001624c1b2 24. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000162f9c70 25. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x00000000162fa55a 26. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc6653 27. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000000fccc4c3 28. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc3d92 29. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fcca080 30. ? @ 0x00007fbc6213eac3 31. ? @ 0x00007fbc621d0850 (version 25.3.6.10636.altinitytest (altinity build)) 2025.07.28 12:03:48.595158 [ 62065 ] {946b3ab7-67b1-40b5-8de6-98ee59a1cf3e} executeQuery: Code: 43. DB::Exception: Illegal argument of type Date32 for function toMinute: while executing 'FUNCTION toMinute(__table1.x1 :: 1) -> toMinute(__table1.x1) UInt8 : 0'. (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.6.10636.altinitytest (altinity build)) (from [::1]:35182) (comment: 01921_datatype_date32.sql) (query 20, line 22) (in query: select toMinute(x1) from t1;), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type>, char const*&) @ 0x000000000a06d8cb 4. /build/src/Functions/DateTimeTransforms.cpp:18: DB::throwDate32IsNotSupported(char const*) @ 0x000000000a06d7a5 5. /build/src/Functions/DateTimeTransforms.h:1541: COW::immutable_ptr DB::DateTimeTransformImpl, DB::ToMinuteImpl, false>::execute(std::vector> const&, std::shared_ptr const&, unsigned long, DB::ToMinuteImpl const&) @ 0x000000000e85ce1e 6. /build/src/Functions/FunctionDateOrDateTimeToSomething.h:74: DB::FunctionDateOrDateTimeToSomething, DB::ToMinuteImpl>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000e85c1cd 7. /build/src/Functions/IFunctionAdaptors.cpp:10: DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000012d995fa 8. /build/src/Functions/IFunction.cpp:353: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d93b52 9. /build/src/Functions/IFunction.cpp:420: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d95059 10. /build/src/Functions/IFunction.cpp:498: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d95c72 11. /build/src/Interpreters/ExpressionActions.cpp:636: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x00000000145176f3 12. /build/src/Processors/Transforms/ExpressionTransform.cpp:25: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x0000000016c0b34c 13. /build/src/Processors/ISimpleTransform.h:33: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000011a9a453 14. /build/src/Processors/ISimpleTransform.cpp:89: DB::ISimpleTransform::work() @ 0x000000001699fca0 15. /build/src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x00000000169bd00f 16. /build/src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x00000000169b2105 17. /build/src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeSingleThread(unsigned long) @ 0x00000000169b23be 18. /build/src/Processors/Executors/PipelineExecutor.cpp:454: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x00000000169b0be7 19. /build/src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x00000000169b03f4 20. /build/src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:se190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169bfeab 21. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc3d92 22. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fcca080 23. ? @ 0x00007fbc6213eac3 24. ? @ 0x00007fbc621d0850 2025.07.28 12:03:48.602264 [ 62065 ] {} TCPHandler: Code: 43. DB::Exception: Illegal argument of type Date32 for function toMinute: while executing 'FUNCTION toMinute(__table1.x1 :: 1) -> toMinute(__table1.x1) UInt8 : 0'. (ILLEGAL_TYPE_OF_ARGUMENT), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type>, char const*&) @ 0x000000000a06d8cb 4. /build/src/Functions/DateTimeTransforms.cpp:18: DB::throwDate32IsNotSupported(char const*) @ 0x000000000a06d7a5 5. /build/src/Functions/DateTimeTransforms.h:1541: COW::immutable_ptr DB::DateTimeTransformImpl, DB::ToMinuteImpl, false>::execute(std::vector> const&, std::shared_ptr const&, unsigned long, DB::ToMinuteImpl const&) @ 0x000000000e85ce1e 6. /build/src/Functions/FunctionDateOrDateTimeToSomething.h:74: DB::FunctionDateOrDateTimeToSomething, DB::ToMinuteImpl>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000e85c1cd 7. /build/src/Functions/IFunctionAdaptors.cpp:10: DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000012d995fa 8. /build/src/Functions/IFunction.cpp:353: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d93b52 9. /build/src/Functions/IFunction.cpp:420: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d95059 10. /build/src/Functions/IFunction.cpp:498: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d95c72 11. /build/src/Interpreters/ExpressionActions.cpp:636: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x00000000145176f3 12. /build/src/Processors/Transforms/ExpressionTransform.cpp:25: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x0000000016c0b34c 13. /build/src/Processors/ISimpleTransform.h:33: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000011a9a453 14. /build/src/Processors/ISimpleTransform.cpp:89: DB::ISimpleTransform::work() @ 0x000000001699fca0 15. /build/src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x00000000169bd00f 16. /build/src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x00000000169b2105 17. /build/src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeSingleThread(unsigned long) @ 0x00000000169b23be 18. /build/src/Processors/Executors/PipelineExecutor.cpp:454: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x00000000169b0be7 19. /build/src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x00000000169b03f4 20. /build/src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:se190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169bfeab 21. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc3d92 22. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fcca080 23. ? @ 0x00007fbc6213eac3 24. ? @ 0x00007fbc621d0850 Job's origin stack trace: 0. /build/src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000000fc33b84 1. /build/src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000000fcc2ea7 2. /build/src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fcc535c 3. /build/src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000000fcc584d 4. /build/src/Common/ThreadPool.h:279: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x00000000169bf193 5. /build/src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x00000000169bf518 6. /build/src/Server/TCPHandler.cpp:1237: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x00000000168f1525 7. /build/src/Server/TCPHandler.cpp:678: DB::TCPHandler::runImpl() @ 0x00000000168e68e5 8. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 9. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 10. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 11. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 12. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 13. ? @ 0x00007fbc6213eac3 14. ? @ 0x00007fbc621d0850 2025.07.28 12:03:48.789783 [ 62065 ] {fd9bf26a-d977-41f2-a12d-ccce04f170c2} executeQuery: Code: 43. DB::Exception: Illegal argument of type Date32 for function toSecond: while executing 'FUNCTION toSecond(__table1.x1 :: 1) -> toSecond(__table1.x1) UInt8 : 0'. (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.6.10636.altinitytest (altinity build)) (from [::1]:35182) (comment: 01921_datatype_date32.sql) (query 22, line 24) (in query: select toSecond(x1) from t1;), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type>, char const*&) @ 0x000000000a06d8cb 4. /build/src/Functions/DateTimeTransforms.cpp:18: DB::throwDate32IsNotSupported(char const*) @ 0x000000000a06d7a5 5. /build/src/Functions/DateTimeTransforms.h:1569: COW::immutable_ptr DB::DateTimeTransformImpl, DB::ToSecondImpl, false>::execute(std::vector> const&, std::shared_ptr const&, unsigned long, DB::ToSecondImpl const&) @ 0x000000000e877bbe 6. /build/src/Functions/FunctionDateOrDateTimeToSomething.h:74: DB::FunctionDateOrDateTimeToSomething, DB::ToSecondImpl>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000e876f6d 7. /build/src/Functions/IFunctionAdaptors.cpp:10: DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000012d995fa 8. /build/src/Functions/IFunction.cpp:353: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d93b52 9. /build/src/Functions/IFunction.cpp:420: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d95059 10. /build/src/Functions/IFunction.cpp:498: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d95c72 11. /build/src/Interpreters/ExpressionActions.cpp:636: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x00000000145176f3 12. /build/src/Processors/Transforms/ExpressionTransform.cpp:25: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x0000000016c0b34c 13. /build/src/Processors/ISimpleTransform.h:33: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000011a9a453 14. /build/src/Processors/ISimpleTransform.cpp:89: DB::ISimpleTransform::work() @ 0x000000001699fca0 15. /build/src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x00000000169bd00f 16. /build/src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x00000000169b2105 17. /build/src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeSingleThread(unsigned long) @ 0x00000000169b23be 18. /build/src/Processors/Executors/PipelineExecutor.cpp:454: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x00000000169b0be7 19. /build/src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x00000000169b03f4 20. /build/src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:se190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169bfeab 21. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc3d92 22. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fcca080 23. ? @ 0x00007fbc6213eac3 24. ? @ 0x00007fbc621d0850 2025.07.28 12:03:48.795977 [ 62065 ] {} TCPHandler: Code: 43. DB::Exception: Illegal argument of type Date32 for function toSecond: while executing 'FUNCTION toSecond(__table1.x1 :: 1) -> toSecond(__table1.x1) UInt8 : 0'. (ILLEGAL_TYPE_OF_ARGUMENT), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type>, char const*&) @ 0x000000000a06d8cb 4. /build/src/Functions/DateTimeTransforms.cpp:18: DB::throwDate32IsNotSupported(char const*) @ 0x000000000a06d7a5 5. /build/src/Functions/DateTimeTransforms.h:1569: COW::immutable_ptr DB::DateTimeTransformImpl, DB::ToSecondImpl, false>::execute(std::vector> const&, std::shared_ptr const&, unsigned long, DB::ToSecondImpl const&) @ 0x000000000e877bbe 6. /build/src/Functions/FunctionDateOrDateTimeToSomething.h:74: DB::FunctionDateOrDateTimeToSomething, DB::ToSecondImpl>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000e876f6d 7. /build/src/Functions/IFunctionAdaptors.cpp:10: DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000012d995fa 8. /build/src/Functions/IFunction.cpp:353: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d93b52 9. /build/src/Functions/IFunction.cpp:420: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d95059 10. /build/src/Functions/IFunction.cpp:498: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d95c72 11. /build/src/Interpreters/ExpressionActions.cpp:636: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x00000000145176f3 12. /build/src/Processors/Transforms/ExpressionTransform.cpp:25: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x0000000016c0b34c 13. /build/src/Processors/ISimpleTransform.h:33: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000011a9a453 14. /build/src/Processors/ISimpleTransform.cpp:89: DB::ISimpleTransform::work() @ 0x000000001699fca0 15. /build/src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x00000000169bd00f 16. /build/src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x00000000169b2105 17. /build/src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeSingleThread(unsigned long) @ 0x00000000169b23be 18. /build/src/Processors/Executors/PipelineExecutor.cpp:454: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x00000000169b0be7 19. /build/src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x00000000169b03f4 20. /build/src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:se190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169bfeab 21. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc3d92 22. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fcca080 23. ? @ 0x00007fbc6213eac3 24. ? @ 0x00007fbc621d0850 Job's origin stack trace: 0. /build/src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000000fc33b84 1. /build/src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000000fcc2ea7 2. /build/src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fcc535c 3. /build/src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000000fcc584d 4. /build/src/Common/ThreadPool.h:279: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x00000000169bf193 5. /build/src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x00000000169bf518 6. /build/src/Server/TCPHandler.cpp:1237: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x00000000168f1525 7. /build/src/Server/TCPHandler.cpp:678: DB::TCPHandler::runImpl() @ 0x00000000168e68e5 8. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 9. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 10. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 11. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 12. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 13. ? @ 0x00007fbc6213eac3 14. ? @ 0x00007fbc621d0850 2025.07.28 12:03:48.933567 [ 3965 ] {} test_13.rmt2 (7f9b740d-015c-470e-8cc6-8ba33be0dc63): auto DB::StorageReplicatedMergeTree::processQueueEntry(ReplicatedMergeTreeQueue::SelectedEntryPtr)::(anonymous class)::operator()(LogEntryPtr &) const: Code: 86. DB::HTTPException: Received error from remote server http://146b4357c08d:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Ftest%2F01165%2Ftest_13%2Frmt%2Freplicas%2F1&part=20250728_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.6.10636.altinitytest (altinity build)) '. (RECEIVED_ERROR_FROM_REMOTE_IO_SERVER), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.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 const&, int&&, String const&, unsigned long&&, String const&) @ 0x000000000feda8d9 4. /build/src/IO/HTTPCommon.cpp:104: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x000000000feda6e2 5. /build/src/IO/HTTPCommon.cpp:93: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x000000000feda537 6. /build/src/IO/ReadWriteBufferFromHTTP.cpp:277: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x000000001184a4c4 7. /build/src/IO/ReadWriteBufferFromHTTP.cpp:285: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x000000001184a615 8. /build/src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x000000001184ae59 9. /build/src/IO/ReadWriteBufferFromHTTP.cpp:472: void std::__function::__policy_invoker::__call_impl[abi:se190107]>(std::__function::__policy_storage const*) @ 0x000000001184cedd 10. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001184858b 11. /build/src/IO/ReadWriteBufferFromHTTP.cpp:465: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x000000001184bf0b 12. /build/src/IO/ReadBuffer.h:60: DB::ReadBuffer::next() @ 0x000000000a148c7b 13. /build/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) @ 0x0000000011849fb2 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]>&)>&, 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&) @ 0x0000000011841980 15. /build/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) @ 0x000000001621208e 16. /build/src/Storages/StorageReplicatedMergeTree.cpp:5228: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl[abi:se190107] const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000015f9a5fe 17. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000015ed8bfd 18. /build/src/Storages/StorageReplicatedMergeTree.cpp:2514: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x0000000015ec9aab 19. /build/src/Storages/StorageReplicatedMergeTree.cpp:2349: DB::StorageReplicatedMergeTree::executeLogEntry(DB::ReplicatedMergeTreeLogEntry&) @ 0x0000000015eba91b 20. /build/src/Storages/StorageReplicatedMergeTree.cpp:3876: bool std::__function::__policy_invoker&)>::__call_impl[abi:se190107])::$_1, bool (std::shared_ptr&)>>(std::__function::__policy_storage const*, std::shared_ptr&) @ 0x0000000015f9837e 21. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000165d6fc3 22. /build/src/Storages/StorageReplicatedMergeTree.cpp:3872: DB::StorageReplicatedMergeTree::processQueueEntry(std::shared_ptr) @ 0x0000000015efc18a 23. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001624c1b2 24. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000162f9c70 25. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x00000000162fa55a 26. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc6653 27. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000000fccc4c3 28. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc3d92 29. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fcca080 30. ? @ 0x00007fbc6213eac3 31. ? @ 0x00007fbc621d0850 (version 25.3.6.10636.altinitytest (altinity build)) 2025.07.28 12:03:49.075913 [ 3961 ] {} test_13.rmt2 (7f9b740d-015c-470e-8cc6-8ba33be0dc63): auto DB::StorageReplicatedMergeTree::processQueueEntry(ReplicatedMergeTreeQueue::SelectedEntryPtr)::(anonymous class)::operator()(LogEntryPtr &) const: Code: 86. DB::HTTPException: Received error from remote server http://146b4357c08d:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Ftest%2F01165%2Ftest_13%2Frmt%2Freplicas%2F1&part=20250728_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.6.10636.altinitytest (altinity build)) '. (RECEIVED_ERROR_FROM_REMOTE_IO_SERVER), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.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 const&, int&&, String const&, unsigned long&&, String const&) @ 0x000000000feda8d9 4. /build/src/IO/HTTPCommon.cpp:104: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x000000000feda6e2 5. /build/src/IO/HTTPCommon.cpp:93: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x000000000feda537 6. /build/src/IO/ReadWriteBufferFromHTTP.cpp:277: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x000000001184a4c4 7. /build/src/IO/ReadWriteBufferFromHTTP.cpp:285: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x000000001184a615 8. /build/src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x000000001184ae59 9. /build/src/IO/ReadWriteBufferFromHTTP.cpp:472: void std::__function::__policy_invoker::__call_impl[abi:se190107]>(std::__function::__policy_storage const*) @ 0x000000001184cedd 10. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001184858b 11. /build/src/IO/ReadWriteBufferFromHTTP.cpp:465: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x000000001184bf0b 12. /build/src/IO/ReadBuffer.h:60: DB::ReadBuffer::next() @ 0x000000000a148c7b 13. /build/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) @ 0x0000000011849fb2 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]>&)>&, 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&) @ 0x0000000011841980 15. /build/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) @ 0x000000001621208e 16. /build/src/Storages/StorageReplicatedMergeTree.cpp:5228: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl[abi:se190107] const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000015f9a5fe 17. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000015ed8bfd 18. /build/src/Storages/StorageReplicatedMergeTree.cpp:2514: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x0000000015ec9aab 19. /build/src/Storages/StorageReplicatedMergeTree.cpp:2349: DB::StorageReplicatedMergeTree::executeLogEntry(DB::ReplicatedMergeTreeLogEntry&) @ 0x0000000015eba91b 20. /build/src/Storages/StorageReplicatedMergeTree.cpp:3876: bool std::__function::__policy_invoker&)>::__call_impl[abi:se190107])::$_1, bool (std::shared_ptr&)>>(std::__function::__policy_storage const*, std::shared_ptr&) @ 0x0000000015f9837e 21. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000165d6fc3 22. /build/src/Storages/StorageReplicatedMergeTree.cpp:3872: DB::StorageReplicatedMergeTree::processQueueEntry(std::shared_ptr) @ 0x0000000015efc18a 23. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001624c1b2 24. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000162f9c70 25. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x00000000162fa55a 26. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc6653 27. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000000fccc4c3 28. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc3d92 29. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fcca080 30. ? @ 0x00007fbc6213eac3 31. ? @ 0x00007fbc621d0850 (version 25.3.6.10636.altinitytest (altinity build)) 2025.07.28 12:03:49.348845 [ 3972 ] {} test_13.rmt2 (7f9b740d-015c-470e-8cc6-8ba33be0dc63): auto DB::StorageReplicatedMergeTree::processQueueEntry(ReplicatedMergeTreeQueue::SelectedEntryPtr)::(anonymous class)::operator()(LogEntryPtr &) const: Code: 86. DB::HTTPException: Received error from remote server http://146b4357c08d:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Ftest%2F01165%2Ftest_13%2Frmt%2Freplicas%2F1&part=20250728_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.6.10636.altinitytest (altinity build)) '. (RECEIVED_ERROR_FROM_REMOTE_IO_SERVER), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.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 const&, int&&, String const&, unsigned long&&, String const&) @ 0x000000000feda8d9 4. /build/src/IO/HTTPCommon.cpp:104: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x000000000feda6e2 5. /build/src/IO/HTTPCommon.cpp:93: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x000000000feda537 6. /build/src/IO/ReadWriteBufferFromHTTP.cpp:277: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x000000001184a4c4 7. /build/src/IO/ReadWriteBufferFromHTTP.cpp:285: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x000000001184a615 8. /build/src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x000000001184ae59 9. /build/src/IO/ReadWriteBufferFromHTTP.cpp:472: void std::__function::__policy_invoker::__call_impl[abi:se190107]>(std::__function::__policy_storage const*) @ 0x000000001184cedd 10. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001184858b 11. /build/src/IO/ReadWriteBufferFromHTTP.cpp:465: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x000000001184bf0b 12. /build/src/IO/ReadBuffer.h:60: DB::ReadBuffer::next() @ 0x000000000a148c7b 13. /build/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) @ 0x0000000011849fb2 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]>&)>&, 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&) @ 0x0000000011841980 15. /build/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) @ 0x000000001621208e 16. /build/src/Storages/StorageReplicatedMergeTree.cpp:5228: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl[abi:se190107] const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000015f9a5fe 17. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000015ed8bfd 18. /build/src/Storages/StorageReplicatedMergeTree.cpp:2514: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x0000000015ec9aab 19. /build/src/Storages/StorageReplicatedMergeTree.cpp:2349: DB::StorageReplicatedMergeTree::executeLogEntry(DB::ReplicatedMergeTreeLogEntry&) @ 0x0000000015eba91b 20. /build/src/Storages/StorageReplicatedMergeTree.cpp:3876: bool std::__function::__policy_invoker&)>::__call_impl[abi:se190107])::$_1, bool (std::shared_ptr&)>>(std::__function::__policy_storage const*, std::shared_ptr&) @ 0x0000000015f9837e 21. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000165d6fc3 22. /build/src/Storages/StorageReplicatedMergeTree.cpp:3872: DB::StorageReplicatedMergeTree::processQueueEntry(std::shared_ptr) @ 0x0000000015efc18a 23. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001624c1b2 24. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000162f9c70 25. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x00000000162fa55a 26. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc6653 27. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000000fccc4c3 28. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc3d92 29. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fcca080 30. ? @ 0x00007fbc6213eac3 31. ? @ 0x00007fbc621d0850 (version 25.3.6.10636.altinitytest (altinity build)) 2025.07.28 12:03:49.470871 [ 4446 ] {920b4e08-8047-455c-8148-613ea4bb8b40} executeQuery: Code: 439. DB::Exception: Cannot schedule a task: failed to start the thread (threads=1, jobs=1). (CANNOT_SCHEDULE_TASK) (version 25.3.6.10636.altinitytest (altinity build)) (from [::1]:35258) (comment: 02423_insert_stats_behaviour.sh) (query 1, line 1) (in query: SELECT read_rows, read_bytes, written_rows, written_bytes, query FROM system.query_log WHERE event_date >= yesterday() AND event_time > now() - INTERVAL 600 SECOND AND type = 'QueryFinish' AND query_kind = 'Insert' AND current_database == currentDatabase() ORDER BY event_time_microseconds ASC FORMAT TSKV), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000fccaeeb 4. /build/src/Common/ThreadPool.cpp:275: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000fccc813 5. /build/src/Common/ThreadPool.cpp:308: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fcc8286 6. /build/src/Common/ThreadPool.cpp:494: ThreadPoolImpl>::scheduleOrThrowOnError(std::function, Priority) @ 0x000000000fcc7a0e 7. /build/src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::spawnThreadsImpl() @ 0x00000000169b2c0c 8. /build/src/Processors/Executors/PipelineExecutor.cpp:394: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x00000000169b0ba7 9. /build/src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x00000000169b03f4 10. /build/src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:se190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169bfeab 11. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc3d92 12. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fcca080 13. ? @ 0x00007fbc6213eac3 14. ? @ 0x00007fbc621d0850 2025.07.28 12:03:49.486665 [ 4446 ] {} 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. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000fccaeeb 4. /build/src/Common/ThreadPool.cpp:275: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000fccc813 5. /build/src/Common/ThreadPool.cpp:308: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fcc8286 6. /build/src/Common/ThreadPool.cpp:494: ThreadPoolImpl>::scheduleOrThrowOnError(std::function, Priority) @ 0x000000000fcc7a0e 7. /build/src/Processors/Executors/PipelineExecutor.cpp:410: DB::PipelineExecutor::spawnThreadsImpl() @ 0x00000000169b2c0c 8. /build/src/Processors/Executors/PipelineExecutor.cpp:394: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x00000000169b0ba7 9. /build/src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x00000000169b03f4 10. /build/src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:se190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169bfeab 11. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc3d92 12. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fcca080 13. ? @ 0x00007fbc6213eac3 14. ? @ 0x00007fbc621d0850 Job's origin stack trace: 0. /build/src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000000fc33b84 1. /build/src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000000fcc2ea7 2. /build/src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fcc535c 3. /build/src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000000fcc584d 4. /build/src/Common/ThreadPool.h:279: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x00000000169bf193 5. /build/src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x00000000169bf518 6. /build/src/Server/TCPHandler.cpp:1237: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x00000000168f1525 7. /build/src/Server/TCPHandler.cpp:678: DB::TCPHandler::runImpl() @ 0x00000000168e68e5 8. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 9. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 10. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 11. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 12. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 13. ? @ 0x00007fbc6213eac3 14. ? @ 0x00007fbc621d0850 2025.07.28 12:03:50.029938 [ 3974 ] {} test_13.rmt2 (7f9b740d-015c-470e-8cc6-8ba33be0dc63): auto DB::StorageReplicatedMergeTree::processQueueEntry(ReplicatedMergeTreeQueue::SelectedEntryPtr)::(anonymous class)::operator()(LogEntryPtr &) const: Code: 86. DB::HTTPException: Received error from remote server http://146b4357c08d:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Ftest%2F01165%2Ftest_13%2Frmt%2Freplicas%2F1&part=20250728_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.6.10636.altinitytest (altinity build)) '. (RECEIVED_ERROR_FROM_REMOTE_IO_SERVER), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.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 const&, int&&, String const&, unsigned long&&, String const&) @ 0x000000000feda8d9 4. /build/src/IO/HTTPCommon.cpp:104: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x000000000feda6e2 5. /build/src/IO/HTTPCommon.cpp:93: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x000000000feda537 6. /build/src/IO/ReadWriteBufferFromHTTP.cpp:277: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x000000001184a4c4 7. /build/src/IO/ReadWriteBufferFromHTTP.cpp:285: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x000000001184a615 8. /build/src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x000000001184ae59 9. /build/src/IO/ReadWriteBufferFromHTTP.cpp:472: void std::__function::__policy_invoker::__call_impl[abi:se190107]>(std::__function::__policy_storage const*) @ 0x000000001184cedd 10. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001184858b 11. /build/src/IO/ReadWriteBufferFromHTTP.cpp:465: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x000000001184bf0b 12. /build/src/IO/ReadBuffer.h:60: DB::ReadBuffer::next() @ 0x000000000a148c7b 13. /build/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) @ 0x0000000011849fb2 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]>&)>&, 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&) @ 0x0000000011841980 15. /build/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) @ 0x000000001621208e 16. /build/src/Storages/StorageReplicatedMergeTree.cpp:5228: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl[abi:se190107] const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000015f9a5fe 17. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000015ed8bfd 18. /build/src/Storages/StorageReplicatedMergeTree.cpp:2514: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x0000000015ec9aab 19. /build/src/Storages/StorageReplicatedMergeTree.cpp:2349: DB::StorageReplicatedMergeTree::executeLogEntry(DB::ReplicatedMergeTreeLogEntry&) @ 0x0000000015eba91b 20. /build/src/Storages/StorageReplicatedMergeTree.cpp:3876: bool std::__function::__policy_invoker&)>::__call_impl[abi:se190107])::$_1, bool (std::shared_ptr&)>>(std::__function::__policy_storage const*, std::shared_ptr&) @ 0x0000000015f9837e 21. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000165d6fc3 22. /build/src/Storages/StorageReplicatedMergeTree.cpp:3872: DB::StorageReplicatedMergeTree::processQueueEntry(std::shared_ptr) @ 0x0000000015efc18a 23. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001624c1b2 24. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000162f9c70 25. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x00000000162fa55a 26. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc6653 27. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000000fccc4c3 28. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc3d92 29. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fcca080 30. ? @ 0x00007fbc6213eac3 31. ? @ 0x00007fbc621d0850 (version 25.3.6.10636.altinitytest (altinity build)) 2025.07.28 12:03:50.731657 [ 3964 ] {} test_13.rmt2 (7f9b740d-015c-470e-8cc6-8ba33be0dc63): auto DB::StorageReplicatedMergeTree::processQueueEntry(ReplicatedMergeTreeQueue::SelectedEntryPtr)::(anonymous class)::operator()(LogEntryPtr &) const: Code: 86. DB::HTTPException: Received error from remote server http://146b4357c08d:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Ftest%2F01165%2Ftest_13%2Frmt%2Freplicas%2F1&part=20250728_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.6.10636.altinitytest (altinity build)) '. (RECEIVED_ERROR_FROM_REMOTE_IO_SERVER), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.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 const&, int&&, String const&, unsigned long&&, String const&) @ 0x000000000feda8d9 4. /build/src/IO/HTTPCommon.cpp:104: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x000000000feda6e2 5. /build/src/IO/HTTPCommon.cpp:93: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x000000000feda537 6. /build/src/IO/ReadWriteBufferFromHTTP.cpp:277: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x000000001184a4c4 7. /build/src/IO/ReadWriteBufferFromHTTP.cpp:285: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x000000001184a615 8. /build/src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x000000001184ae59 9. /build/src/IO/ReadWriteBufferFromHTTP.cpp:472: void std::__function::__policy_invoker::__call_impl[abi:se190107]>(std::__function::__policy_storage const*) @ 0x000000001184cedd 10. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001184858b 11. /build/src/IO/ReadWriteBufferFromHTTP.cpp:465: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x000000001184bf0b 12. /build/src/IO/ReadBuffer.h:60: DB::ReadBuffer::next() @ 0x000000000a148c7b 13. /build/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) @ 0x0000000011849fb2 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]>&)>&, 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&) @ 0x0000000011841980 15. /build/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) @ 0x000000001621208e 16. /build/src/Storages/StorageReplicatedMergeTree.cpp:5228: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl[abi:se190107] const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000015f9a5fe 17. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000015ed8bfd 18. /build/src/Storages/StorageReplicatedMergeTree.cpp:2514: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x0000000015ec9aab 19. /build/src/Storages/StorageReplicatedMergeTree.cpp:2349: DB::StorageReplicatedMergeTree::executeLogEntry(DB::ReplicatedMergeTreeLogEntry&) @ 0x0000000015eba91b 20. /build/src/Storages/StorageReplicatedMergeTree.cpp:3876: bool std::__function::__policy_invoker&)>::__call_impl[abi:se190107])::$_1, bool (std::shared_ptr&)>>(std::__function::__policy_storage const*, std::shared_ptr&) @ 0x0000000015f9837e 21. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000165d6fc3 22. /build/src/Storages/StorageReplicatedMergeTree.cpp:3872: DB::StorageReplicatedMergeTree::processQueueEntry(std::shared_ptr) @ 0x0000000015efc18a 23. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001624c1b2 24. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000162f9c70 25. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x00000000162fa55a 26. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc6653 27. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000000fccc4c3 28. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc3d92 29. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fcca080 30. ? @ 0x00007fbc6213eac3 31. ? @ 0x00007fbc621d0850 (version 25.3.6.10636.altinitytest (altinity build)) 2025.07.28 12:03:51.066389 [ 62065 ] {fa57e190-5cb2-4d23-ae32-e428b94e58f6} executeQuery: Code: 43. DB::Exception: Illegal argument of type Date32 for function toStartOfSecond: while executing 'FUNCTION toStartOfSecond(__table1.x1 :: 1) -> toStartOfSecond(__table1.x1) DateTime64(3) : 0'. (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.6.10636.altinitytest (altinity build)) (from [::1]:35182) (comment: 01921_datatype_date32.sql) (query 46, line 48) (in query: select toStartOfSecond(x1) from t1;), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type>, char const*&) @ 0x000000000a06d8cb 4. /build/src/Functions/DateTimeTransforms.cpp:18: DB::throwDate32IsNotSupported(char const*) @ 0x000000000a06d7a5 5. /build/src/Functions/DateTimeTransforms.h:878: COW::immutable_ptr DB::DateTimeTransformImpl::execute(std::vector> const&, std::shared_ptr const&, unsigned long, DB::ToStartOfSecondImpl const&) @ 0x000000000e8c31d9 6. /build/src/Functions/FunctionDateOrDateTimeToSomething.h:74: DB::FunctionDateOrDateTimeToSomething::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000e8c29ed 7. /build/src/Functions/IFunctionAdaptors.cpp:10: DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000012d995fa 8. /build/src/Functions/IFunction.cpp:353: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d93b52 9. /build/src/Functions/IFunction.cpp:420: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d95059 10. /build/src/Functions/IFunction.cpp:498: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d95c72 11. /build/src/Interpreters/ExpressionActions.cpp:636: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x00000000145176f3 12. /build/src/Processors/Transforms/ExpressionTransform.cpp:25: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x0000000016c0b34c 13. /build/src/Processors/ISimpleTransform.h:33: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000011a9a453 14. /build/src/Processors/ISimpleTransform.cpp:89: DB::ISimpleTransform::work() @ 0x000000001699fca0 15. /build/src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x00000000169bd00f 16. /build/src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x00000000169b2105 17. /build/src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeSingleThread(unsigned long) @ 0x00000000169b23be 18. /build/src/Processors/Executors/PipelineExecutor.cpp:454: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x00000000169b0be7 19. /build/src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x00000000169b03f4 20. /build/src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:se190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169bfeab 21. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc3d92 22. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fcca080 23. ? @ 0x00007fbc6213eac3 24. ? @ 0x00007fbc621d0850 2025.07.28 12:03:51.074803 [ 62065 ] {} TCPHandler: Code: 43. DB::Exception: Illegal argument of type Date32 for function toStartOfSecond: while executing 'FUNCTION toStartOfSecond(__table1.x1 :: 1) -> toStartOfSecond(__table1.x1) DateTime64(3) : 0'. (ILLEGAL_TYPE_OF_ARGUMENT), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type>, char const*&) @ 0x000000000a06d8cb 4. /build/src/Functions/DateTimeTransforms.cpp:18: DB::throwDate32IsNotSupported(char const*) @ 0x000000000a06d7a5 5. /build/src/Functions/DateTimeTransforms.h:878: COW::immutable_ptr DB::DateTimeTransformImpl::execute(std::vector> const&, std::shared_ptr const&, unsigned long, DB::ToStartOfSecondImpl const&) @ 0x000000000e8c31d9 6. /build/src/Functions/FunctionDateOrDateTimeToSomething.h:74: DB::FunctionDateOrDateTimeToSomething::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000e8c29ed 7. /build/src/Functions/IFunctionAdaptors.cpp:10: DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000012d995fa 8. /build/src/Functions/IFunction.cpp:353: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d93b52 9. /build/src/Functions/IFunction.cpp:420: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d95059 10. /build/src/Functions/IFunction.cpp:498: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d95c72 11. /build/src/Interpreters/ExpressionActions.cpp:636: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x00000000145176f3 12. /build/src/Processors/Transforms/ExpressionTransform.cpp:25: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x0000000016c0b34c 13. /build/src/Processors/ISimpleTransform.h:33: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000011a9a453 14. /build/src/Processors/ISimpleTransform.cpp:89: DB::ISimpleTransform::work() @ 0x000000001699fca0 15. /build/src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x00000000169bd00f 16. /build/src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x00000000169b2105 17. /build/src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeSingleThread(unsigned long) @ 0x00000000169b23be 18. /build/src/Processors/Executors/PipelineExecutor.cpp:454: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x00000000169b0be7 19. /build/src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x00000000169b03f4 20. /build/src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:se190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169bfeab 21. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc3d92 22. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fcca080 23. ? @ 0x00007fbc6213eac3 24. ? @ 0x00007fbc621d0850 Job's origin stack trace: 0. /build/src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000000fc33b84 1. /build/src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000000fcc2ea7 2. /build/src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fcc535c 3. /build/src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000000fcc584d 4. /build/src/Common/ThreadPool.h:279: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x00000000169bf193 5. /build/src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x00000000169bf518 6. /build/src/Server/TCPHandler.cpp:1237: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x00000000168f1525 7. /build/src/Server/TCPHandler.cpp:678: DB::TCPHandler::runImpl() @ 0x00000000168e68e5 8. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 9. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 10. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 11. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 12. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 13. ? @ 0x00007fbc6213eac3 14. ? @ 0x00007fbc621d0850 2025.07.28 12:03:51.255114 [ 62065 ] {4c93dd69-a2d7-4650-8bee-94727923891a} executeQuery: Code: 43. DB::Exception: Illegal argument of type Date32 for function toStartOfMinute: while executing 'FUNCTION toStartOfMinute(__table1.x1 :: 1) -> toStartOfMinute(__table1.x1) DateTime : 0'. (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.6.10636.altinitytest (altinity build)) (from [::1]:35182) (comment: 01921_datatype_date32.sql) (query 48, line 50) (in query: select toStartOfMinute(x1) from t1;), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type>, char const*&) @ 0x000000000a06d8cb 4. /build/src/Functions/DateTimeTransforms.cpp:18: DB::throwDate32IsNotSupported(char const*) @ 0x000000000a06d7a5 5. /build/src/Functions/DateTimeTransforms.h:831: COW::immutable_ptr DB::DateTimeTransformImpl::execute(std::vector> const&, std::shared_ptr const&, unsigned long, DB::ToStartOfMinuteImpl const&) @ 0x000000000e8bc6f9 6. /build/src/Functions/FunctionDateOrDateTimeToDateTimeOrDateTime64.h:77: DB::FunctionDateOrDateTimeToDateTimeOrDateTime64::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000e8bbbbe 7. /build/src/Functions/IFunctionAdaptors.cpp:10: DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000012d995fa 8. /build/src/Functions/IFunction.cpp:353: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d93b52 9. /build/src/Functions/IFunction.cpp:420: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d95059 10. /build/src/Functions/IFunction.cpp:498: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d95c72 11. /build/src/Interpreters/ExpressionActions.cpp:636: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x00000000145176f3 12. /build/src/Processors/Transforms/ExpressionTransform.cpp:25: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x0000000016c0b34c 13. /build/src/Processors/ISimpleTransform.h:33: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000011a9a453 14. /build/src/Processors/ISimpleTransform.cpp:89: DB::ISimpleTransform::work() @ 0x000000001699fca0 15. /build/src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x00000000169bd00f 16. /build/src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x00000000169b2105 17. /build/src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeSingleThread(unsigned long) @ 0x00000000169b23be 18. /build/src/Processors/Executors/PipelineExecutor.cpp:454: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x00000000169b0be7 19. /build/src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x00000000169b03f4 20. /build/src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:se190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169bfeab 21. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc3d92 22. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fcca080 23. ? @ 0x00007fbc6213eac3 24. ? @ 0x00007fbc621d0850 2025.07.28 12:03:51.261106 [ 62065 ] {} TCPHandler: Code: 43. DB::Exception: Illegal argument of type Date32 for function toStartOfMinute: while executing 'FUNCTION toStartOfMinute(__table1.x1 :: 1) -> toStartOfMinute(__table1.x1) DateTime : 0'. (ILLEGAL_TYPE_OF_ARGUMENT), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type>, char const*&) @ 0x000000000a06d8cb 4. /build/src/Functions/DateTimeTransforms.cpp:18: DB::throwDate32IsNotSupported(char const*) @ 0x000000000a06d7a5 5. /build/src/Functions/DateTimeTransforms.h:831: COW::immutable_ptr DB::DateTimeTransformImpl::execute(std::vector> const&, std::shared_ptr const&, unsigned long, DB::ToStartOfMinuteImpl const&) @ 0x000000000e8bc6f9 6. /build/src/Functions/FunctionDateOrDateTimeToDateTimeOrDateTime64.h:77: DB::FunctionDateOrDateTimeToDateTimeOrDateTime64::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000e8bbbbe 7. /build/src/Functions/IFunctionAdaptors.cpp:10: DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000012d995fa 8. /build/src/Functions/IFunction.cpp:353: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d93b52 9. /build/src/Functions/IFunction.cpp:420: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d95059 10. /build/src/Functions/IFunction.cpp:498: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d95c72 11. /build/src/Interpreters/ExpressionActions.cpp:636: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x00000000145176f3 12. /build/src/Processors/Transforms/ExpressionTransform.cpp:25: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x0000000016c0b34c 13. /build/src/Processors/ISimpleTransform.h:33: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000011a9a453 14. /build/src/Processors/ISimpleTransform.cpp:89: DB::ISimpleTransform::work() @ 0x000000001699fca0 15. /build/src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x00000000169bd00f 16. /build/src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x00000000169b2105 17. /build/src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeSingleThread(unsigned long) @ 0x00000000169b23be 18. /build/src/Processors/Executors/PipelineExecutor.cpp:454: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x00000000169b0be7 19. /build/src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x00000000169b03f4 20. /build/src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:se190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169bfeab 21. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc3d92 22. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fcca080 23. ? @ 0x00007fbc6213eac3 24. ? @ 0x00007fbc621d0850 Job's origin stack trace: 0. /build/src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000000fc33b84 1. /build/src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000000fcc2ea7 2. /build/src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fcc535c 3. /build/src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000000fcc584d 4. /build/src/Common/ThreadPool.h:279: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x00000000169bf193 5. /build/src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x00000000169bf518 6. /build/src/Server/TCPHandler.cpp:1237: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x00000000168f1525 7. /build/src/Server/TCPHandler.cpp:678: DB::TCPHandler::runImpl() @ 0x00000000168e68e5 8. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 9. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 10. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 11. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 12. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 13. ? @ 0x00007fbc6213eac3 14. ? @ 0x00007fbc621d0850 2025.07.28 12:03:51.295989 [ 3977 ] {} test_13.rmt2 (7f9b740d-015c-470e-8cc6-8ba33be0dc63): auto DB::StorageReplicatedMergeTree::processQueueEntry(ReplicatedMergeTreeQueue::SelectedEntryPtr)::(anonymous class)::operator()(LogEntryPtr &) const: Code: 86. DB::HTTPException: Received error from remote server http://146b4357c08d:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Ftest%2F01165%2Ftest_13%2Frmt%2Freplicas%2F1&part=20250728_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.6.10636.altinitytest (altinity build)) '. (RECEIVED_ERROR_FROM_REMOTE_IO_SERVER), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.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 const&, int&&, String const&, unsigned long&&, String const&) @ 0x000000000feda8d9 4. /build/src/IO/HTTPCommon.cpp:104: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x000000000feda6e2 5. /build/src/IO/HTTPCommon.cpp:93: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x000000000feda537 6. /build/src/IO/ReadWriteBufferFromHTTP.cpp:277: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x000000001184a4c4 7. /build/src/IO/ReadWriteBufferFromHTTP.cpp:285: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x000000001184a615 8. /build/src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x000000001184ae59 9. /build/src/IO/ReadWriteBufferFromHTTP.cpp:472: void std::__function::__policy_invoker::__call_impl[abi:se190107]>(std::__function::__policy_storage const*) @ 0x000000001184cedd 10. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001184858b 11. /build/src/IO/ReadWriteBufferFromHTTP.cpp:465: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x000000001184bf0b 12. /build/src/IO/ReadBuffer.h:60: DB::ReadBuffer::next() @ 0x000000000a148c7b 13. /build/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) @ 0x0000000011849fb2 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]>&)>&, 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&) @ 0x0000000011841980 15. /build/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) @ 0x000000001621208e 16. /build/src/Storages/StorageReplicatedMergeTree.cpp:5228: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl[abi:se190107] const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000015f9a5fe 17. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000015ed8bfd 18. /build/src/Storages/StorageReplicatedMergeTree.cpp:2514: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x0000000015ec9aab 19. /build/src/Storages/StorageReplicatedMergeTree.cpp:2349: DB::StorageReplicatedMergeTree::executeLogEntry(DB::ReplicatedMergeTreeLogEntry&) @ 0x0000000015eba91b 20. /build/src/Storages/StorageReplicatedMergeTree.cpp:3876: bool std::__function::__policy_invoker&)>::__call_impl[abi:se190107])::$_1, bool (std::shared_ptr&)>>(std::__function::__policy_storage const*, std::shared_ptr&) @ 0x0000000015f9837e 21. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000165d6fc3 22. /build/src/Storages/StorageReplicatedMergeTree.cpp:3872: DB::StorageReplicatedMergeTree::processQueueEntry(std::shared_ptr) @ 0x0000000015efc18a 23. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001624c1b2 24. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000162f9c70 25. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x00000000162fa55a 26. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc6653 27. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000000fccc4c3 28. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc3d92 29. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fcca080 30. ? @ 0x00007fbc6213eac3 31. ? @ 0x00007fbc621d0850 (version 25.3.6.10636.altinitytest (altinity build)) 2025.07.28 12:03:51.503653 [ 62065 ] {a4e36d38-c8f7-4706-9639-1cb13f184d52} executeQuery: Code: 43. DB::Exception: Illegal argument of type Date32 for function toStartOfFiveMinutes: while executing 'FUNCTION toStartOfFiveMinutes(__table1.x1 :: 1) -> toStartOfFiveMinutes(__table1.x1) DateTime : 0'. (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.6.10636.altinitytest (altinity build)) (from [::1]:35182) (comment: 01921_datatype_date32.sql) (query 50, line 52) (in query: select toStartOfFiveMinutes(x1) from t1;), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type>, char const*&) @ 0x000000000a06d8cb 4. /build/src/Functions/DateTimeTransforms.cpp:18: DB::throwDate32IsNotSupported(char const*) @ 0x000000000a06d7a5 5. /build/src/Functions/DateTimeTransforms.h:1029: COW::immutable_ptr DB::DateTimeTransformImpl::execute(std::vector> const&, std::shared_ptr const&, unsigned long, DB::ToStartOfFiveMinutesImpl const&) @ 0x000000000e87e2b9 6. /build/src/Functions/FunctionDateOrDateTimeToDateTimeOrDateTime64.h:77: DB::FunctionDateOrDateTimeToDateTimeOrDateTime64::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000e87d77e 7. /build/src/Functions/IFunctionAdaptors.cpp:10: DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000012d995fa 8. /build/src/Functions/IFunction.cpp:353: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d93b52 9. /build/src/Functions/IFunction.cpp:420: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d95059 10. /build/src/Functions/IFunction.cpp:498: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d95c72 11. /build/src/Interpreters/ExpressionActions.cpp:636: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x00000000145176f3 12. /build/src/Processors/Transforms/ExpressionTransform.cpp:25: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x0000000016c0b34c 13. /build/src/Processors/ISimpleTransform.h:33: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000011a9a453 14. /build/src/Processors/ISimpleTransform.cpp:89: DB::ISimpleTransform::work() @ 0x000000001699fca0 15. /build/src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x00000000169bd00f 16. /build/src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x00000000169b2105 17. /build/src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeSingleThread(unsigned long) @ 0x00000000169b23be 18. /build/src/Processors/Executors/PipelineExecutor.cpp:454: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x00000000169b0be7 19. /build/src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x00000000169b03f4 20. /build/src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:se190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169bfeab 21. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc3d92 22. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fcca080 23. ? @ 0x00007fbc6213eac3 24. ? @ 0x00007fbc621d0850 2025.07.28 12:03:51.507380 [ 62065 ] {} TCPHandler: Code: 43. DB::Exception: Illegal argument of type Date32 for function toStartOfFiveMinutes: while executing 'FUNCTION toStartOfFiveMinutes(__table1.x1 :: 1) -> toStartOfFiveMinutes(__table1.x1) DateTime : 0'. (ILLEGAL_TYPE_OF_ARGUMENT), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type>, char const*&) @ 0x000000000a06d8cb 4. /build/src/Functions/DateTimeTransforms.cpp:18: DB::throwDate32IsNotSupported(char const*) @ 0x000000000a06d7a5 5. /build/src/Functions/DateTimeTransforms.h:1029: COW::immutable_ptr DB::DateTimeTransformImpl::execute(std::vector> const&, std::shared_ptr const&, unsigned long, DB::ToStartOfFiveMinutesImpl const&) @ 0x000000000e87e2b9 6. /build/src/Functions/FunctionDateOrDateTimeToDateTimeOrDateTime64.h:77: DB::FunctionDateOrDateTimeToDateTimeOrDateTime64::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000e87d77e 7. /build/src/Functions/IFunctionAdaptors.cpp:10: DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000012d995fa 8. /build/src/Functions/IFunction.cpp:353: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d93b52 9. /build/src/Functions/IFunction.cpp:420: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d95059 10. /build/src/Functions/IFunction.cpp:498: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d95c72 11. /build/src/Interpreters/ExpressionActions.cpp:636: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x00000000145176f3 12. /build/src/Processors/Transforms/ExpressionTransform.cpp:25: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x0000000016c0b34c 13. /build/src/Processors/ISimpleTransform.h:33: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000011a9a453 14. /build/src/Processors/ISimpleTransform.cpp:89: DB::ISimpleTransform::work() @ 0x000000001699fca0 15. /build/src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x00000000169bd00f 16. /build/src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x00000000169b2105 17. /build/src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeSingleThread(unsigned long) @ 0x00000000169b23be 18. /build/src/Processors/Executors/PipelineExecutor.cpp:454: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x00000000169b0be7 19. /build/src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x00000000169b03f4 20. /build/src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:se190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169bfeab 21. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc3d92 22. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fcca080 23. ? @ 0x00007fbc6213eac3 24. ? @ 0x00007fbc621d0850 Job's origin stack trace: 0. /build/src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000000fc33b84 1. /build/src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000000fcc2ea7 2. /build/src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fcc535c 3. /build/src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000000fcc584d 4. /build/src/Common/ThreadPool.h:279: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x00000000169bf193 5. /build/src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x00000000169bf518 6. /build/src/Server/TCPHandler.cpp:1237: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x00000000168f1525 7. /build/src/Server/TCPHandler.cpp:678: DB::TCPHandler::runImpl() @ 0x00000000168e68e5 8. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 9. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 10. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 11. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 12. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 13. ? @ 0x00007fbc6213eac3 14. ? @ 0x00007fbc621d0850 2025.07.28 12:03:51.750008 [ 62065 ] {9a734619-e382-4317-b106-e754500a9493} executeQuery: Code: 43. DB::Exception: Illegal argument of type Date32 for function toStartOfTenMinutes: while executing 'FUNCTION toStartOfTenMinutes(__table1.x1 :: 1) -> toStartOfTenMinutes(__table1.x1) DateTime : 0'. (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.6.10636.altinitytest (altinity build)) (from [::1]:35182) (comment: 01921_datatype_date32.sql) (query 52, line 54) (in query: select toStartOfTenMinutes(x1) from t1;), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type>, char const*&) @ 0x000000000a06d8cb 4. /build/src/Functions/DateTimeTransforms.cpp:18: DB::throwDate32IsNotSupported(char const*) @ 0x000000000a06d7a5 5. /build/src/Functions/DateTimeTransforms.h:1061: COW::immutable_ptr DB::DateTimeTransformImpl::execute(std::vector> const&, std::shared_ptr const&, unsigned long, DB::ToStartOfTenMinutesImpl const&) @ 0x000000000e8c98b9 6. /build/src/Functions/FunctionDateOrDateTimeToDateTimeOrDateTime64.h:77: DB::FunctionDateOrDateTimeToDateTimeOrDateTime64::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000e8c8d7e 7. /build/src/Functions/IFunctionAdaptors.cpp:10: DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000012d995fa 8. /build/src/Functions/IFunction.cpp:353: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d93b52 9. /build/src/Functions/IFunction.cpp:420: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d95059 10. /build/src/Functions/IFunction.cpp:498: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d95c72 11. /build/src/Interpreters/ExpressionActions.cpp:636: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x00000000145176f3 12. /build/src/Processors/Transforms/ExpressionTransform.cpp:25: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x0000000016c0b34c 13. /build/src/Processors/ISimpleTransform.h:33: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000011a9a453 14. /build/src/Processors/ISimpleTransform.cpp:89: DB::ISimpleTransform::work() @ 0x000000001699fca0 15. /build/src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x00000000169bd00f 16. /build/src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x00000000169b2105 17. /build/src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeSingleThread(unsigned long) @ 0x00000000169b23be 18. /build/src/Processors/Executors/PipelineExecutor.cpp:454: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x00000000169b0be7 19. /build/src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x00000000169b03f4 20. /build/src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:se190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169bfeab 21. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc3d92 22. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fcca080 23. ? @ 0x00007fbc6213eac3 24. ? @ 0x00007fbc621d0850 2025.07.28 12:03:51.753363 [ 4446 ] {4abc7484-1a9a-470b-9aa4-ae4d4ae480c6} executeQuery: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=885, jobs=851). (CANNOT_SCHEDULE_TASK) (version 25.3.6.10636.altinitytest (altinity build)) (from [::1]:56100) (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' AND active), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000fccaeeb 4. /build/src/Common/ThreadPool.cpp:275: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000fccacb3 5. /build/src/Common/ThreadPool.cpp:323: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fcc4ffc 6. /build/src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000000fcc584d 7. /build/src/Common/ThreadPool.h:279: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x00000000169bf193 8. /build/src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x00000000169bf518 9. /build/src/Server/TCPHandler.cpp:1237: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x00000000168f1525 10. /build/src/Server/TCPHandler.cpp:678: DB::TCPHandler::runImpl() @ 0x00000000168e68e5 11. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 12. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 13. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 14. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 15. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 16. ? @ 0x00007fbc6213eac3 17. ? @ 0x00007fbc621d0850 2025.07.28 12:03:51.791150 [ 4446 ] {} TCPHandler: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=885, jobs=851). (CANNOT_SCHEDULE_TASK), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String const&, unsigned long&&, unsigned long&) @ 0x000000000fccaeeb 4. /build/src/Common/ThreadPool.cpp:275: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000000fccacb3 5. /build/src/Common/ThreadPool.cpp:323: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fcc4ffc 6. /build/src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000000fcc584d 7. /build/src/Common/ThreadPool.h:279: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x00000000169bf193 8. /build/src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x00000000169bf518 9. /build/src/Server/TCPHandler.cpp:1237: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x00000000168f1525 10. /build/src/Server/TCPHandler.cpp:678: DB::TCPHandler::runImpl() @ 0x00000000168e68e5 11. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 12. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 13. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 14. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 15. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 16. ? @ 0x00007fbc6213eac3 17. ? @ 0x00007fbc621d0850 2025.07.28 12:03:51.831823 [ 62065 ] {} TCPHandler: Code: 43. DB::Exception: Illegal argument of type Date32 for function toStartOfTenMinutes: while executing 'FUNCTION toStartOfTenMinutes(__table1.x1 :: 1) -> toStartOfTenMinutes(__table1.x1) DateTime : 0'. (ILLEGAL_TYPE_OF_ARGUMENT), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type>, char const*&) @ 0x000000000a06d8cb 4. /build/src/Functions/DateTimeTransforms.cpp:18: DB::throwDate32IsNotSupported(char const*) @ 0x000000000a06d7a5 5. /build/src/Functions/DateTimeTransforms.h:1061: COW::immutable_ptr DB::DateTimeTransformImpl::execute(std::vector> const&, std::shared_ptr const&, unsigned long, DB::ToStartOfTenMinutesImpl const&) @ 0x000000000e8c98b9 6. /build/src/Functions/FunctionDateOrDateTimeToDateTimeOrDateTime64.h:77: DB::FunctionDateOrDateTimeToDateTimeOrDateTime64::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000e8c8d7e 7. /build/src/Functions/IFunctionAdaptors.cpp:10: DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000012d995fa 8. /build/src/Functions/IFunction.cpp:353: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d93b52 9. /build/src/Functions/IFunction.cpp:420: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d95059 10. /build/src/Functions/IFunction.cpp:498: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d95c72 11. /build/src/Interpreters/ExpressionActions.cpp:636: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x00000000145176f3 12. /build/src/Processors/Transforms/ExpressionTransform.cpp:25: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x0000000016c0b34c 13. /build/src/Processors/ISimpleTransform.h:33: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000011a9a453 14. /build/src/Processors/ISimpleTransform.cpp:89: DB::ISimpleTransform::work() @ 0x000000001699fca0 15. /build/src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x00000000169bd00f 16. /build/src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x00000000169b2105 17. /build/src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeSingleThread(unsigned long) @ 0x00000000169b23be 18. /build/src/Processors/Executors/PipelineExecutor.cpp:454: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x00000000169b0be7 19. /build/src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x00000000169b03f4 20. /build/src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:se190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169bfeab 21. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc3d92 22. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fcca080 23. ? @ 0x00007fbc6213eac3 24. ? @ 0x00007fbc621d0850 Job's origin stack trace: 0. /build/src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000000fc33b84 1. /build/src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000000fcc2ea7 2. /build/src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fcc535c 3. /build/src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000000fcc584d 4. /build/src/Common/ThreadPool.h:279: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x00000000169bf193 5. /build/src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x00000000169bf518 6. /build/src/Server/TCPHandler.cpp:1237: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x00000000168f1525 7. /build/src/Server/TCPHandler.cpp:678: DB::TCPHandler::runImpl() @ 0x00000000168e68e5 8. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 9. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 10. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 11. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 12. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 13. ? @ 0x00007fbc6213eac3 14. ? @ 0x00007fbc621d0850 2025.07.28 12:03:52.005766 [ 62065 ] {d2747c93-230f-4034-b6ee-b242f5877022} executeQuery: Code: 43. DB::Exception: Illegal argument of type Date32 for function toStartOfFifteenMinutes: while executing 'FUNCTION toStartOfFifteenMinutes(__table1.x1 :: 1) -> toStartOfFifteenMinutes(__table1.x1) DateTime : 0'. (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.6.10636.altinitytest (altinity build)) (from [::1]:35182) (comment: 01921_datatype_date32.sql) (query 54, line 56) (in query: select toStartOfFifteenMinutes(x1) from t1;), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type>, char const*&) @ 0x000000000a06d8cb 4. /build/src/Functions/DateTimeTransforms.cpp:18: DB::throwDate32IsNotSupported(char const*) @ 0x000000000a06d7a5 5. /build/src/Functions/DateTimeTransforms.h:1093: COW::immutable_ptr DB::DateTimeTransformImpl::execute(std::vector> const&, std::shared_ptr const&, unsigned long, DB::ToStartOfFifteenMinutesImpl const&) @ 0x000000000e87bf19 6. /build/src/Functions/FunctionDateOrDateTimeToDateTimeOrDateTime64.h:77: DB::FunctionDateOrDateTimeToDateTimeOrDateTime64::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000e87b3de 7. /build/src/Functions/IFunctionAdaptors.cpp:10: DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000012d995fa 8. /build/src/Functions/IFunction.cpp:353: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d93b52 9. /build/src/Functions/IFunction.cpp:420: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d95059 10. /build/src/Functions/IFunction.cpp:498: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d95c72 11. /build/src/Interpreters/ExpressionActions.cpp:636: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x00000000145176f3 12. /build/src/Processors/Transforms/ExpressionTransform.cpp:25: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x0000000016c0b34c 13. /build/src/Processors/ISimpleTransform.h:33: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000011a9a453 14. /build/src/Processors/ISimpleTransform.cpp:89: DB::ISimpleTransform::work() @ 0x000000001699fca0 15. /build/src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x00000000169bd00f 16. /build/src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x00000000169b2105 17. /build/src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeSingleThread(unsigned long) @ 0x00000000169b23be 18. /build/src/Processors/Executors/PipelineExecutor.cpp:454: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x00000000169b0be7 19. /build/src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x00000000169b03f4 20. /build/src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:se190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169bfeab 21. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc3d92 22. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fcca080 23. ? @ 0x00007fbc6213eac3 24. ? @ 0x00007fbc621d0850 2025.07.28 12:03:52.008641 [ 62065 ] {} TCPHandler: Code: 43. DB::Exception: Illegal argument of type Date32 for function toStartOfFifteenMinutes: while executing 'FUNCTION toStartOfFifteenMinutes(__table1.x1 :: 1) -> toStartOfFifteenMinutes(__table1.x1) DateTime : 0'. (ILLEGAL_TYPE_OF_ARGUMENT), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type>, char const*&) @ 0x000000000a06d8cb 4. /build/src/Functions/DateTimeTransforms.cpp:18: DB::throwDate32IsNotSupported(char const*) @ 0x000000000a06d7a5 5. /build/src/Functions/DateTimeTransforms.h:1093: COW::immutable_ptr DB::DateTimeTransformImpl::execute(std::vector> const&, std::shared_ptr const&, unsigned long, DB::ToStartOfFifteenMinutesImpl const&) @ 0x000000000e87bf19 6. /build/src/Functions/FunctionDateOrDateTimeToDateTimeOrDateTime64.h:77: DB::FunctionDateOrDateTimeToDateTimeOrDateTime64::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000e87b3de 7. /build/src/Functions/IFunctionAdaptors.cpp:10: DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000012d995fa 8. /build/src/Functions/IFunction.cpp:353: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d93b52 9. /build/src/Functions/IFunction.cpp:420: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d95059 10. /build/src/Functions/IFunction.cpp:498: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d95c72 11. /build/src/Interpreters/ExpressionActions.cpp:636: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x00000000145176f3 12. /build/src/Processors/Transforms/ExpressionTransform.cpp:25: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x0000000016c0b34c 13. /build/src/Processors/ISimpleTransform.h:33: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000011a9a453 14. /build/src/Processors/ISimpleTransform.cpp:89: DB::ISimpleTransform::work() @ 0x000000001699fca0 15. /build/src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x00000000169bd00f 16. /build/src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x00000000169b2105 17. /build/src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeSingleThread(unsigned long) @ 0x00000000169b23be 18. /build/src/Processors/Executors/PipelineExecutor.cpp:454: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x00000000169b0be7 19. /build/src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x00000000169b03f4 20. /build/src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:se190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169bfeab 21. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc3d92 22. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fcca080 23. ? @ 0x00007fbc6213eac3 24. ? @ 0x00007fbc621d0850 Job's origin stack trace: 0. /build/src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000000fc33b84 1. /build/src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000000fcc2ea7 2. /build/src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fcc535c 3. /build/src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000000fcc584d 4. /build/src/Common/ThreadPool.h:279: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x00000000169bf193 5. /build/src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x00000000169bf518 6. /build/src/Server/TCPHandler.cpp:1237: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x00000000168f1525 7. /build/src/Server/TCPHandler.cpp:678: DB::TCPHandler::runImpl() @ 0x00000000168e68e5 8. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 9. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 10. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 11. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 12. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 13. ? @ 0x00007fbc6213eac3 14. ? @ 0x00007fbc621d0850 2025.07.28 12:03:52.013451 [ 3971 ] {} test_13.rmt2 (7f9b740d-015c-470e-8cc6-8ba33be0dc63): auto DB::StorageReplicatedMergeTree::processQueueEntry(ReplicatedMergeTreeQueue::SelectedEntryPtr)::(anonymous class)::operator()(LogEntryPtr &) const: Code: 86. DB::HTTPException: Received error from remote server http://146b4357c08d:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Ftest%2F01165%2Ftest_13%2Frmt%2Freplicas%2F1&part=20250728_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.6.10636.altinitytest (altinity build)) '. (RECEIVED_ERROR_FROM_REMOTE_IO_SERVER), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.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 const&, int&&, String const&, unsigned long&&, String const&) @ 0x000000000feda8d9 4. /build/src/IO/HTTPCommon.cpp:104: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x000000000feda6e2 5. /build/src/IO/HTTPCommon.cpp:93: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x000000000feda537 6. /build/src/IO/ReadWriteBufferFromHTTP.cpp:277: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x000000001184a4c4 7. /build/src/IO/ReadWriteBufferFromHTTP.cpp:285: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x000000001184a615 8. /build/src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x000000001184ae59 9. /build/src/IO/ReadWriteBufferFromHTTP.cpp:472: void std::__function::__policy_invoker::__call_impl[abi:se190107]>(std::__function::__policy_storage const*) @ 0x000000001184cedd 10. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001184858b 11. /build/src/IO/ReadWriteBufferFromHTTP.cpp:465: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x000000001184bf0b 12. /build/src/IO/ReadBuffer.h:60: DB::ReadBuffer::next() @ 0x000000000a148c7b 13. /build/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) @ 0x0000000011849fb2 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]>&)>&, 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&) @ 0x0000000011841980 15. /build/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) @ 0x000000001621208e 16. /build/src/Storages/StorageReplicatedMergeTree.cpp:5228: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl[abi:se190107] const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000015f9a5fe 17. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000015ed8bfd 18. /build/src/Storages/StorageReplicatedMergeTree.cpp:2514: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x0000000015ec9aab 19. /build/src/Storages/StorageReplicatedMergeTree.cpp:2349: DB::StorageReplicatedMergeTree::executeLogEntry(DB::ReplicatedMergeTreeLogEntry&) @ 0x0000000015eba91b 20. /build/src/Storages/StorageReplicatedMergeTree.cpp:3876: bool std::__function::__policy_invoker&)>::__call_impl[abi:se190107])::$_1, bool (std::shared_ptr&)>>(std::__function::__policy_storage const*, std::shared_ptr&) @ 0x0000000015f9837e 21. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000165d6fc3 22. /build/src/Storages/StorageReplicatedMergeTree.cpp:3872: DB::StorageReplicatedMergeTree::processQueueEntry(std::shared_ptr) @ 0x0000000015efc18a 23. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001624c1b2 24. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000162f9c70 25. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x00000000162fa55a 26. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc6653 27. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000000fccc4c3 28. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc3d92 29. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fcca080 30. ? @ 0x00007fbc6213eac3 31. ? @ 0x00007fbc621d0850 (version 25.3.6.10636.altinitytest (altinity build)) 2025.07.28 12:03:52.303370 [ 62065 ] {89662d3e-8e16-41c2-bad1-b02c72ac7a93} executeQuery: Code: 43. DB::Exception: Illegal argument of type Date32 for function toStartOfHour: while executing 'FUNCTION toStartOfHour(__table1.x1 :: 1) -> toStartOfHour(__table1.x1) DateTime : 0'. (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.6.10636.altinitytest (altinity build)) (from [::1]:35182) (comment: 01921_datatype_date32.sql) (query 56, line 58) (in query: select toStartOfHour(x1) from t1;), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type>, char const*&) @ 0x000000000a06d8cb 4. /build/src/Functions/DateTimeTransforms.cpp:18: DB::throwDate32IsNotSupported(char const*) @ 0x000000000a06d7a5 5. /build/src/Functions/DateTimeTransforms.h:1167: COW::immutable_ptr DB::DateTimeTransformImpl::execute(std::vector> const&, std::shared_ptr const&, unsigned long, DB::ToStartOfHourImpl const&) @ 0x000000000e880579 6. /build/src/Functions/FunctionDateOrDateTimeToDateTimeOrDateTime64.h:77: DB::FunctionDateOrDateTimeToDateTimeOrDateTime64::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000e87fa3e 7. /build/src/Functions/IFunctionAdaptors.cpp:10: DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000012d995fa 8. /build/src/Functions/IFunction.cpp:353: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d93b52 9. /build/src/Functions/IFunction.cpp:420: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d95059 10. /build/src/Functions/IFunction.cpp:498: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d95c72 11. /build/src/Interpreters/ExpressionActions.cpp:636: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x00000000145176f3 12. /build/src/Processors/Transforms/ExpressionTransform.cpp:25: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x0000000016c0b34c 13. /build/src/Processors/ISimpleTransform.h:33: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000011a9a453 14. /build/src/Processors/ISimpleTransform.cpp:89: DB::ISimpleTransform::work() @ 0x000000001699fca0 15. /build/src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x00000000169bd00f 16. /build/src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x00000000169b2105 17. /build/src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeSingleThread(unsigned long) @ 0x00000000169b23be 18. /build/src/Processors/Executors/PipelineExecutor.cpp:454: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x00000000169b0be7 19. /build/src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x00000000169b03f4 20. /build/src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:se190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169bfeab 21. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc3d92 22. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fcca080 23. ? @ 0x00007fbc6213eac3 24. ? @ 0x00007fbc621d0850 2025.07.28 12:03:52.308181 [ 62065 ] {} TCPHandler: Code: 43. DB::Exception: Illegal argument of type Date32 for function toStartOfHour: while executing 'FUNCTION toStartOfHour(__table1.x1 :: 1) -> toStartOfHour(__table1.x1) DateTime : 0'. (ILLEGAL_TYPE_OF_ARGUMENT), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type>, char const*&) @ 0x000000000a06d8cb 4. /build/src/Functions/DateTimeTransforms.cpp:18: DB::throwDate32IsNotSupported(char const*) @ 0x000000000a06d7a5 5. /build/src/Functions/DateTimeTransforms.h:1167: COW::immutable_ptr DB::DateTimeTransformImpl::execute(std::vector> const&, std::shared_ptr const&, unsigned long, DB::ToStartOfHourImpl const&) @ 0x000000000e880579 6. /build/src/Functions/FunctionDateOrDateTimeToDateTimeOrDateTime64.h:77: DB::FunctionDateOrDateTimeToDateTimeOrDateTime64::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000e87fa3e 7. /build/src/Functions/IFunctionAdaptors.cpp:10: DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000012d995fa 8. /build/src/Functions/IFunction.cpp:353: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d93b52 9. /build/src/Functions/IFunction.cpp:420: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d95059 10. /build/src/Functions/IFunction.cpp:498: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d95c72 11. /build/src/Interpreters/ExpressionActions.cpp:636: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x00000000145176f3 12. /build/src/Processors/Transforms/ExpressionTransform.cpp:25: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x0000000016c0b34c 13. /build/src/Processors/ISimpleTransform.h:33: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000011a9a453 14. /build/src/Processors/ISimpleTransform.cpp:89: DB::ISimpleTransform::work() @ 0x000000001699fca0 15. /build/src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x00000000169bd00f 16. /build/src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x00000000169b2105 17. /build/src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeSingleThread(unsigned long) @ 0x00000000169b23be 18. /build/src/Processors/Executors/PipelineExecutor.cpp:454: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x00000000169b0be7 19. /build/src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x00000000169b03f4 20. /build/src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:se190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169bfeab 21. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc3d92 22. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fcca080 23. ? @ 0x00007fbc6213eac3 24. ? @ 0x00007fbc621d0850 Job's origin stack trace: 0. /build/src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000000fc33b84 1. /build/src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000000fcc2ea7 2. /build/src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fcc535c 3. /build/src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000000fcc584d 4. /build/src/Common/ThreadPool.h:279: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x00000000169bf193 5. /build/src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x00000000169bf518 6. /build/src/Server/TCPHandler.cpp:1237: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x00000000168f1525 7. /build/src/Server/TCPHandler.cpp:678: DB::TCPHandler::runImpl() @ 0x00000000168e68e5 8. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 9. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 10. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 11. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 12. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 13. ? @ 0x00007fbc6213eac3 14. ? @ 0x00007fbc621d0850 2025.07.28 12:03:52.351268 [ 3977 ] {} test_13.rmt2 (7f9b740d-015c-470e-8cc6-8ba33be0dc63): auto DB::StorageReplicatedMergeTree::processQueueEntry(ReplicatedMergeTreeQueue::SelectedEntryPtr)::(anonymous class)::operator()(LogEntryPtr &) const: Code: 86. DB::HTTPException: Received error from remote server http://146b4357c08d:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Ftest%2F01165%2Ftest_13%2Frmt%2Freplicas%2F1&part=20250728_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.6.10636.altinitytest (altinity build)) '. (RECEIVED_ERROR_FROM_REMOTE_IO_SERVER), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.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 const&, int&&, String const&, unsigned long&&, String const&) @ 0x000000000feda8d9 4. /build/src/IO/HTTPCommon.cpp:104: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x000000000feda6e2 5. /build/src/IO/HTTPCommon.cpp:93: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x000000000feda537 6. /build/src/IO/ReadWriteBufferFromHTTP.cpp:277: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x000000001184a4c4 7. /build/src/IO/ReadWriteBufferFromHTTP.cpp:285: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x000000001184a615 8. /build/src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x000000001184ae59 9. /build/src/IO/ReadWriteBufferFromHTTP.cpp:472: void std::__function::__policy_invoker::__call_impl[abi:se190107]>(std::__function::__policy_storage const*) @ 0x000000001184cedd 10. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001184858b 11. /build/src/IO/ReadWriteBufferFromHTTP.cpp:465: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x000000001184bf0b 12. /build/src/IO/ReadBuffer.h:60: DB::ReadBuffer::next() @ 0x000000000a148c7b 13. /build/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) @ 0x0000000011849fb2 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]>&)>&, 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&) @ 0x0000000011841980 15. /build/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) @ 0x000000001621208e 16. /build/src/Storages/StorageReplicatedMergeTree.cpp:5228: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl[abi:se190107] const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000015f9a5fe 17. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000015ed8bfd 18. /build/src/Storages/StorageReplicatedMergeTree.cpp:2514: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x0000000015ec9aab 19. /build/src/Storages/StorageReplicatedMergeTree.cpp:2349: DB::StorageReplicatedMergeTree::executeLogEntry(DB::ReplicatedMergeTreeLogEntry&) @ 0x0000000015eba91b 20. /build/src/Storages/StorageReplicatedMergeTree.cpp:3876: bool std::__function::__policy_invoker&)>::__call_impl[abi:se190107])::$_1, bool (std::shared_ptr&)>>(std::__function::__policy_storage const*, std::shared_ptr&) @ 0x0000000015f9837e 21. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000165d6fc3 22. /build/src/Storages/StorageReplicatedMergeTree.cpp:3872: DB::StorageReplicatedMergeTree::processQueueEntry(std::shared_ptr) @ 0x0000000015efc18a 23. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001624c1b2 24. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000162f9c70 25. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x00000000162fa55a 26. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc6653 27. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000000fccc4c3 28. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc3d92 29. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fcca080 30. ? @ 0x00007fbc6213eac3 31. ? @ 0x00007fbc621d0850 (version 25.3.6.10636.altinitytest (altinity build)) 2025.07.28 12:03:52.886681 [ 3965 ] {} test_13.rmt2 (7f9b740d-015c-470e-8cc6-8ba33be0dc63): auto DB::StorageReplicatedMergeTree::processQueueEntry(ReplicatedMergeTreeQueue::SelectedEntryPtr)::(anonymous class)::operator()(LogEntryPtr &) const: Code: 86. DB::HTTPException: Received error from remote server http://146b4357c08d:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Ftest%2F01165%2Ftest_13%2Frmt%2Freplicas%2F1&part=20250728_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.6.10636.altinitytest (altinity build)) '. (RECEIVED_ERROR_FROM_REMOTE_IO_SERVER), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.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 const&, int&&, String const&, unsigned long&&, String const&) @ 0x000000000feda8d9 4. /build/src/IO/HTTPCommon.cpp:104: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x000000000feda6e2 5. /build/src/IO/HTTPCommon.cpp:93: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x000000000feda537 6. /build/src/IO/ReadWriteBufferFromHTTP.cpp:277: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x000000001184a4c4 7. /build/src/IO/ReadWriteBufferFromHTTP.cpp:285: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x000000001184a615 8. /build/src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x000000001184ae59 9. /build/src/IO/ReadWriteBufferFromHTTP.cpp:472: void std::__function::__policy_invoker::__call_impl[abi:se190107]>(std::__function::__policy_storage const*) @ 0x000000001184cedd 10. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001184858b 11. /build/src/IO/ReadWriteBufferFromHTTP.cpp:465: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x000000001184bf0b 12. /build/src/IO/ReadBuffer.h:60: DB::ReadBuffer::next() @ 0x000000000a148c7b 13. /build/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) @ 0x0000000011849fb2 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]>&)>&, 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&) @ 0x0000000011841980 15. /build/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) @ 0x000000001621208e 16. /build/src/Storages/StorageReplicatedMergeTree.cpp:5228: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl[abi:se190107] const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000015f9a5fe 17. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000015ed8bfd 18. /build/src/Storages/StorageReplicatedMergeTree.cpp:2514: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x0000000015ec9aab 19. /build/src/Storages/StorageReplicatedMergeTree.cpp:2349: DB::StorageReplicatedMergeTree::executeLogEntry(DB::ReplicatedMergeTreeLogEntry&) @ 0x0000000015eba91b 20. /build/src/Storages/StorageReplicatedMergeTree.cpp:3876: bool std::__function::__policy_invoker&)>::__call_impl[abi:se190107])::$_1, bool (std::shared_ptr&)>>(std::__function::__policy_storage const*, std::shared_ptr&) @ 0x0000000015f9837e 21. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000165d6fc3 22. /build/src/Storages/StorageReplicatedMergeTree.cpp:3872: DB::StorageReplicatedMergeTree::processQueueEntry(std::shared_ptr) @ 0x0000000015efc18a 23. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001624c1b2 24. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000162f9c70 25. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x00000000162fa55a 26. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc6653 27. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000000fccc4c3 28. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc3d92 29. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fcca080 30. ? @ 0x00007fbc6213eac3 31. ? @ 0x00007fbc621d0850 (version 25.3.6.10636.altinitytest (altinity build)) 2025.07.28 12:03:53.298687 [ 3970 ] {} test_13.rmt2 (7f9b740d-015c-470e-8cc6-8ba33be0dc63): auto DB::StorageReplicatedMergeTree::processQueueEntry(ReplicatedMergeTreeQueue::SelectedEntryPtr)::(anonymous class)::operator()(LogEntryPtr &) const: Code: 86. DB::HTTPException: Received error from remote server http://146b4357c08d:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Ftest%2F01165%2Ftest_13%2Frmt%2Freplicas%2F1&part=20250728_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.6.10636.altinitytest (altinity build)) '. (RECEIVED_ERROR_FROM_REMOTE_IO_SERVER), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.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 const&, int&&, String const&, unsigned long&&, String const&) @ 0x000000000feda8d9 4. /build/src/IO/HTTPCommon.cpp:104: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x000000000feda6e2 5. /build/src/IO/HTTPCommon.cpp:93: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x000000000feda537 6. /build/src/IO/ReadWriteBufferFromHTTP.cpp:277: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x000000001184a4c4 7. /build/src/IO/ReadWriteBufferFromHTTP.cpp:285: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x000000001184a615 8. /build/src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x000000001184ae59 9. /build/src/IO/ReadWriteBufferFromHTTP.cpp:472: void std::__function::__policy_invoker::__call_impl[abi:se190107]>(std::__function::__policy_storage const*) @ 0x000000001184cedd 10. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001184858b 11. /build/src/IO/ReadWriteBufferFromHTTP.cpp:465: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x000000001184bf0b 12. /build/src/IO/ReadBuffer.h:60: DB::ReadBuffer::next() @ 0x000000000a148c7b 13. /build/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) @ 0x0000000011849fb2 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]>&)>&, 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&) @ 0x0000000011841980 15. /build/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) @ 0x000000001621208e 16. /build/src/Storages/StorageReplicatedMergeTree.cpp:5228: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl[abi:se190107] const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000015f9a5fe 17. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000015ed8bfd 18. /build/src/Storages/StorageReplicatedMergeTree.cpp:2514: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x0000000015ec9aab 19. /build/src/Storages/StorageReplicatedMergeTree.cpp:2349: DB::StorageReplicatedMergeTree::executeLogEntry(DB::ReplicatedMergeTreeLogEntry&) @ 0x0000000015eba91b 20. /build/src/Storages/StorageReplicatedMergeTree.cpp:3876: bool std::__function::__policy_invoker&)>::__call_impl[abi:se190107])::$_1, bool (std::shared_ptr&)>>(std::__function::__policy_storage const*, std::shared_ptr&) @ 0x0000000015f9837e 21. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000165d6fc3 22. /build/src/Storages/StorageReplicatedMergeTree.cpp:3872: DB::StorageReplicatedMergeTree::processQueueEntry(std::shared_ptr) @ 0x0000000015efc18a 23. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001624c1b2 24. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000162f9c70 25. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x00000000162fa55a 26. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc6653 27. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000000fccc4c3 28. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc3d92 29. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fcca080 30. ? @ 0x00007fbc6213eac3 31. ? @ 0x00007fbc621d0850 (version 25.3.6.10636.altinitytest (altinity build)) 2025.07.28 12:03:53.742472 [ 3964 ] {} test_13.rmt2 (7f9b740d-015c-470e-8cc6-8ba33be0dc63): auto DB::StorageReplicatedMergeTree::processQueueEntry(ReplicatedMergeTreeQueue::SelectedEntryPtr)::(anonymous class)::operator()(LogEntryPtr &) const: Code: 86. DB::HTTPException: Received error from remote server http://146b4357c08d:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Ftest%2F01165%2Ftest_13%2Frmt%2Freplicas%2F1&part=20250728_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.6.10636.altinitytest (altinity build)) '. (RECEIVED_ERROR_FROM_REMOTE_IO_SERVER), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.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 const&, int&&, String const&, unsigned long&&, String const&) @ 0x000000000feda8d9 4. /build/src/IO/HTTPCommon.cpp:104: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x000000000feda6e2 5. /build/src/IO/HTTPCommon.cpp:93: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x000000000feda537 6. /build/src/IO/ReadWriteBufferFromHTTP.cpp:277: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x000000001184a4c4 7. /build/src/IO/ReadWriteBufferFromHTTP.cpp:285: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x000000001184a615 8. /build/src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x000000001184ae59 9. /build/src/IO/ReadWriteBufferFromHTTP.cpp:472: void std::__function::__policy_invoker::__call_impl[abi:se190107]>(std::__function::__policy_storage const*) @ 0x000000001184cedd 10. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001184858b 11. /build/src/IO/ReadWriteBufferFromHTTP.cpp:465: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x000000001184bf0b 12. /build/src/IO/ReadBuffer.h:60: DB::ReadBuffer::next() @ 0x000000000a148c7b 13. /build/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) @ 0x0000000011849fb2 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]>&)>&, 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&) @ 0x0000000011841980 15. /build/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) @ 0x000000001621208e 16. /build/src/Storages/StorageReplicatedMergeTree.cpp:5228: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl[abi:se190107] const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000015f9a5fe 17. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000015ed8bfd 18. /build/src/Storages/StorageReplicatedMergeTree.cpp:2514: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x0000000015ec9aab 19. /build/src/Storages/StorageReplicatedMergeTree.cpp:2349: DB::StorageReplicatedMergeTree::executeLogEntry(DB::ReplicatedMergeTreeLogEntry&) @ 0x0000000015eba91b 20. /build/src/Storages/StorageReplicatedMergeTree.cpp:3876: bool std::__function::__policy_invoker&)>::__call_impl[abi:se190107])::$_1, bool (std::shared_ptr&)>>(std::__function::__policy_storage const*, std::shared_ptr&) @ 0x0000000015f9837e 21. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000165d6fc3 22. /build/src/Storages/StorageReplicatedMergeTree.cpp:3872: DB::StorageReplicatedMergeTree::processQueueEntry(std::shared_ptr) @ 0x0000000015efc18a 23. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001624c1b2 24. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000162f9c70 25. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x00000000162fa55a 26. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc6653 27. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000000fccc4c3 28. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc3d92 29. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fcca080 30. ? @ 0x00007fbc6213eac3 31. ? @ 0x00007fbc621d0850 (version 25.3.6.10636.altinitytest (altinity build)) 2025.07.28 12:03:53.988755 [ 62065 ] {44ccf95a-56e3-4f3b-9fd2-c533714f62e5} executeQuery: Code: 43. DB::Exception: Illegal argument of type Date32 for function toTime: while executing 'FUNCTION toTime(__table1.x1 :: 1) -> toTime(__table1.x1) DateTime : 0'. (ILLEGAL_TYPE_OF_ARGUMENT) (version 25.3.6.10636.altinitytest (altinity build)) (from [::1]:35182) (comment: 01921_datatype_date32.sql) (query 76, line 78) (in query: select toTime(x1) from t1;), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type>, char const*&) @ 0x000000000a06d8cb 4. /build/src/Functions/DateTimeTransforms.cpp:18: DB::throwDate32IsNotSupported(char const*) @ 0x000000000a06d7a5 5. /build/src/Functions/DateTimeTransforms.h:806: COW::immutable_ptr DB::DateTimeTransformImpl::execute(std::vector> const&, std::shared_ptr const&, unsigned long, DB::ToTimeImpl const&) @ 0x000000000e8ce0b9 6. /build/src/Functions/FunctionDateOrDateTimeToSomething.h:74: DB::FunctionDateOrDateTimeToSomething::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000e8cd4ed 7. /build/src/Functions/IFunctionAdaptors.cpp:10: DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000012d995fa 8. /build/src/Functions/IFunction.cpp:353: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d93b52 9. /build/src/Functions/IFunction.cpp:420: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d95059 10. /build/src/Functions/IFunction.cpp:498: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d95c72 11. /build/src/Interpreters/ExpressionActions.cpp:636: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x00000000145176f3 12. /build/src/Processors/Transforms/ExpressionTransform.cpp:25: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x0000000016c0b34c 13. /build/src/Processors/ISimpleTransform.h:33: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000011a9a453 14. /build/src/Processors/ISimpleTransform.cpp:89: DB::ISimpleTransform::work() @ 0x000000001699fca0 15. /build/src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x00000000169bd00f 16. /build/src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x00000000169b2105 17. /build/src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeSingleThread(unsigned long) @ 0x00000000169b23be 18. /build/src/Processors/Executors/PipelineExecutor.cpp:454: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x00000000169b0be7 19. /build/src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x00000000169b03f4 20. /build/src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:se190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169bfeab 21. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc3d92 22. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fcca080 23. ? @ 0x00007fbc6213eac3 24. ? @ 0x00007fbc621d0850 2025.07.28 12:03:53.991296 [ 62065 ] {} TCPHandler: Code: 43. DB::Exception: Illegal argument of type Date32 for function toTime: while executing 'FUNCTION toTime(__table1.x1 :: 1) -> toTime(__table1.x1) DateTime : 0'. (ILLEGAL_TYPE_OF_ARGUMENT), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception(int, FormatStringHelperImpl::type>, char const*&) @ 0x000000000a06d8cb 4. /build/src/Functions/DateTimeTransforms.cpp:18: DB::throwDate32IsNotSupported(char const*) @ 0x000000000a06d7a5 5. /build/src/Functions/DateTimeTransforms.h:806: COW::immutable_ptr DB::DateTimeTransformImpl::execute(std::vector> const&, std::shared_ptr const&, unsigned long, DB::ToTimeImpl const&) @ 0x000000000e8ce0b9 6. /build/src/Functions/FunctionDateOrDateTimeToSomething.h:74: DB::FunctionDateOrDateTimeToSomething::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000e8cd4ed 7. /build/src/Functions/IFunctionAdaptors.cpp:10: DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000012d995fa 8. /build/src/Functions/IFunction.cpp:353: DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d93b52 9. /build/src/Functions/IFunction.cpp:420: DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d95059 10. /build/src/Functions/IFunction.cpp:498: DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x0000000012d95c72 11. /build/src/Interpreters/ExpressionActions.cpp:636: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x00000000145176f3 12. /build/src/Processors/Transforms/ExpressionTransform.cpp:25: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x0000000016c0b34c 13. /build/src/Processors/ISimpleTransform.h:33: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x0000000011a9a453 14. /build/src/Processors/ISimpleTransform.cpp:89: DB::ISimpleTransform::work() @ 0x000000001699fca0 15. /build/src/Processors/Executors/ExecutionThreadContext.cpp:53: DB::ExecutionThreadContext::executeTask() @ 0x00000000169bd00f 16. /build/src/Processors/Executors/PipelineExecutor.cpp:296: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x00000000169b2105 17. /build/src/Processors/Executors/PipelineExecutor.cpp:262: DB::PipelineExecutor::executeSingleThread(unsigned long) @ 0x00000000169b23be 18. /build/src/Processors/Executors/PipelineExecutor.cpp:454: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x00000000169b0be7 19. /build/src/Processors/Executors/PipelineExecutor.cpp:128: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x00000000169b03f4 20. /build/src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:76: void std::__function::__policy_invoker::__call_impl[abi:se190107]::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000169bfeab 21. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc3d92 22. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fcca080 23. ? @ 0x00007fbc6213eac3 24. ? @ 0x00007fbc621d0850 Job's origin stack trace: 0. /build/src/Common/StackTrace.cpp:386: StackTrace::StackTrace() @ 0x000000000fc33b84 1. /build/src/Common/ThreadPool.cpp:130: void boost::heap::priority_queue, boost::parameter::void_, boost::parameter::void_, boost::parameter::void_>::emplace, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const, bool&, (anonymous namespace)::ScopedDecrement>(std::function&&, Priority&, StrongTypedef&, DB::OpenTelemetry::TracingContextOnThread const&&, bool&, (anonymous namespace)::ScopedDecrement&&) @ 0x000000000fcc2ea7 2. /build/src/Common/ThreadPool.cpp:401: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000000fcc535c 3. /build/src/Common/ThreadPool.cpp:506: ThreadPoolImpl::scheduleOrThrow(std::function, Priority, unsigned long, bool) @ 0x000000000fcc584d 4. /build/src/Common/ThreadPool.h:279: DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long) @ 0x00000000169bf193 5. /build/src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:131: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x00000000169bf518 6. /build/src/Server/TCPHandler.cpp:1237: DB::TCPHandler::processOrdinaryQuery(DB::QueryState&) @ 0x00000000168f1525 7. /build/src/Server/TCPHandler.cpp:678: DB::TCPHandler::runImpl() @ 0x00000000168e68e5 8. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 9. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 10. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 11. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 12. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 13. ? @ 0x00007fbc6213eac3 14. ? @ 0x00007fbc621d0850 2025.07.28 12:03:54.203094 [ 3963 ] {} test_13.rmt2 (7f9b740d-015c-470e-8cc6-8ba33be0dc63): auto DB::StorageReplicatedMergeTree::processQueueEntry(ReplicatedMergeTreeQueue::SelectedEntryPtr)::(anonymous class)::operator()(LogEntryPtr &) const: Code: 86. DB::HTTPException: Received error from remote server http://146b4357c08d:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Ftest%2F01165%2Ftest_13%2Frmt%2Freplicas%2F1&part=20250728_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.6.10636.altinitytest (altinity build)) '. (RECEIVED_ERROR_FROM_REMOTE_IO_SERVER), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.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 const&, int&&, String const&, unsigned long&&, String const&) @ 0x000000000feda8d9 4. /build/src/IO/HTTPCommon.cpp:104: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x000000000feda6e2 5. /build/src/IO/HTTPCommon.cpp:93: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x000000000feda537 6. /build/src/IO/ReadWriteBufferFromHTTP.cpp:277: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x000000001184a4c4 7. /build/src/IO/ReadWriteBufferFromHTTP.cpp:285: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x000000001184a615 8. /build/src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x000000001184ae59 9. /build/src/IO/ReadWriteBufferFromHTTP.cpp:472: void std::__function::__policy_invoker::__call_impl[abi:se190107]>(std::__function::__policy_storage const*) @ 0x000000001184cedd 10. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001184858b 11. /build/src/IO/ReadWriteBufferFromHTTP.cpp:465: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x000000001184bf0b 12. /build/src/IO/ReadBuffer.h:60: DB::ReadBuffer::next() @ 0x000000000a148c7b 13. /build/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) @ 0x0000000011849fb2 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]>&)>&, 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&) @ 0x0000000011841980 15. /build/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) @ 0x000000001621208e 16. /build/src/Storages/StorageReplicatedMergeTree.cpp:5228: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl[abi:se190107] const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000015f9a5fe 17. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000015ed8bfd 18. /build/src/Storages/StorageReplicatedMergeTree.cpp:2514: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x0000000015ec9aab 19. /build/src/Storages/StorageReplicatedMergeTree.cpp:2349: DB::StorageReplicatedMergeTree::executeLogEntry(DB::ReplicatedMergeTreeLogEntry&) @ 0x0000000015eba91b 20. /build/src/Storages/StorageReplicatedMergeTree.cpp:3876: bool std::__function::__policy_invoker&)>::__call_impl[abi:se190107])::$_1, bool (std::shared_ptr&)>>(std::__function::__policy_storage const*, std::shared_ptr&) @ 0x0000000015f9837e 21. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000165d6fc3 22. /build/src/Storages/StorageReplicatedMergeTree.cpp:3872: DB::StorageReplicatedMergeTree::processQueueEntry(std::shared_ptr) @ 0x0000000015efc18a 23. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001624c1b2 24. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000162f9c70 25. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x00000000162fa55a 26. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc6653 27. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000000fccc4c3 28. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc3d92 29. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fcca080 30. ? @ 0x00007fbc6213eac3 31. ? @ 0x00007fbc621d0850 (version 25.3.6.10636.altinitytest (altinity build)) 2025.07.28 12:03:54.798406 [ 3961 ] {} test_13.rmt2 (7f9b740d-015c-470e-8cc6-8ba33be0dc63): auto DB::StorageReplicatedMergeTree::processQueueEntry(ReplicatedMergeTreeQueue::SelectedEntryPtr)::(anonymous class)::operator()(LogEntryPtr &) const: Code: 86. DB::HTTPException: Received error from remote server http://146b4357c08d:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Ftest%2F01165%2Ftest_13%2Frmt%2Freplicas%2F1&part=20250728_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.6.10636.altinitytest (altinity build)) '. (RECEIVED_ERROR_FROM_REMOTE_IO_SERVER), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.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 const&, int&&, String const&, unsigned long&&, String const&) @ 0x000000000feda8d9 4. /build/src/IO/HTTPCommon.cpp:104: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x000000000feda6e2 5. /build/src/IO/HTTPCommon.cpp:93: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x000000000feda537 6. /build/src/IO/ReadWriteBufferFromHTTP.cpp:277: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x000000001184a4c4 7. /build/src/IO/ReadWriteBufferFromHTTP.cpp:285: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x000000001184a615 8. /build/src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x000000001184ae59 9. /build/src/IO/ReadWriteBufferFromHTTP.cpp:472: void std::__function::__policy_invoker::__call_impl[abi:se190107]>(std::__function::__policy_storage const*) @ 0x000000001184cedd 10. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001184858b 11. /build/src/IO/ReadWriteBufferFromHTTP.cpp:465: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x000000001184bf0b 12. /build/src/IO/ReadBuffer.h:60: DB::ReadBuffer::next() @ 0x000000000a148c7b 13. /build/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) @ 0x0000000011849fb2 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]>&)>&, 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&) @ 0x0000000011841980 15. /build/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) @ 0x000000001621208e 16. /build/src/Storages/StorageReplicatedMergeTree.cpp:5228: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl[abi:se190107] const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000015f9a5fe 17. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000015ed8bfd 18. /build/src/Storages/StorageReplicatedMergeTree.cpp:2514: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x0000000015ec9aab 19. /build/src/Storages/StorageReplicatedMergeTree.cpp:2349: DB::StorageReplicatedMergeTree::executeLogEntry(DB::ReplicatedMergeTreeLogEntry&) @ 0x0000000015eba91b 20. /build/src/Storages/StorageReplicatedMergeTree.cpp:3876: bool std::__function::__policy_invoker&)>::__call_impl[abi:se190107])::$_1, bool (std::shared_ptr&)>>(std::__function::__policy_storage const*, std::shared_ptr&) @ 0x0000000015f9837e 21. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000165d6fc3 22. /build/src/Storages/StorageReplicatedMergeTree.cpp:3872: DB::StorageReplicatedMergeTree::processQueueEntry(std::shared_ptr) @ 0x0000000015efc18a 23. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001624c1b2 24. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000162f9c70 25. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x00000000162fa55a 26. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc6653 27. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000000fccc4c3 28. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc3d92 29. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fcca080 30. ? @ 0x00007fbc6213eac3 31. ? @ 0x00007fbc621d0850 (version 25.3.6.10636.altinitytest (altinity build)) 2025.07.28 12:03:55.239905 [ 62057 ] {} 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. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception>&, String>(int, FormatStringHelperImpl>&>::type, std::type_identity::type>, std::basic_string_view>&, String&&) @ 0x000000001385a5eb 4. /build/src/Access/SettingsConstraints.cpp:376: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000013859b18 5. /build/src/Access/SettingsConstraints.cpp:300: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000013858faf 6. /build/src/Access/SettingsConstraints.cpp:209: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000013859223 7. /build/src/Interpreters/Context.cpp:2690: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000014436134 8. /build/src/Interpreters/Context.cpp:2729: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x000000001443662b 9. /build/src/Server/HTTPHandler.cpp:457: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000001686d165 10. /build/src/Server/HTTPHandler.cpp:753: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x0000000016870807 11. /build/src/Server/HTTP/HTTPServerConnection.cpp:71: DB::HTTPServerConnection::run() @ 0x0000000016907e99 12. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 13. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 14. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 15. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 16. ? @ 0x00007fbc6213eac3 17. ? @ 0x00007fbc621d0850 (version 25.3.6.10636.altinitytest (altinity build)) 2025.07.28 12:03:55.688373 [ 3967 ] {} test_13.rmt2 (7f9b740d-015c-470e-8cc6-8ba33be0dc63): auto DB::StorageReplicatedMergeTree::processQueueEntry(ReplicatedMergeTreeQueue::SelectedEntryPtr)::(anonymous class)::operator()(LogEntryPtr &) const: Code: 86. DB::HTTPException: Received error from remote server http://146b4357c08d:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Ftest%2F01165%2Ftest_13%2Frmt%2Freplicas%2F1&part=20250728_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.6.10636.altinitytest (altinity build)) '. (RECEIVED_ERROR_FROM_REMOTE_IO_SERVER), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.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 const&, int&&, String const&, unsigned long&&, String const&) @ 0x000000000feda8d9 4. /build/src/IO/HTTPCommon.cpp:104: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x000000000feda6e2 5. /build/src/IO/HTTPCommon.cpp:93: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x000000000feda537 6. /build/src/IO/ReadWriteBufferFromHTTP.cpp:277: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x000000001184a4c4 7. /build/src/IO/ReadWriteBufferFromHTTP.cpp:285: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x000000001184a615 8. /build/src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x000000001184ae59 9. /build/src/IO/ReadWriteBufferFromHTTP.cpp:472: void std::__function::__policy_invoker::__call_impl[abi:se190107]>(std::__function::__policy_storage const*) @ 0x000000001184cedd 10. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001184858b 11. /build/src/IO/ReadWriteBufferFromHTTP.cpp:465: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x000000001184bf0b 12. /build/src/IO/ReadBuffer.h:60: DB::ReadBuffer::next() @ 0x000000000a148c7b 13. /build/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) @ 0x0000000011849fb2 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]>&)>&, 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&) @ 0x0000000011841980 15. /build/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) @ 0x000000001621208e 16. /build/src/Storages/StorageReplicatedMergeTree.cpp:5228: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl[abi:se190107] const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000015f9a5fe 17. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000015ed8bfd 18. /build/src/Storages/StorageReplicatedMergeTree.cpp:2514: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x0000000015ec9aab 19. /build/src/Storages/StorageReplicatedMergeTree.cpp:2349: DB::StorageReplicatedMergeTree::executeLogEntry(DB::ReplicatedMergeTreeLogEntry&) @ 0x0000000015eba91b 20. /build/src/Storages/StorageReplicatedMergeTree.cpp:3876: bool std::__function::__policy_invoker&)>::__call_impl[abi:se190107])::$_1, bool (std::shared_ptr&)>>(std::__function::__policy_storage const*, std::shared_ptr&) @ 0x0000000015f9837e 21. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000165d6fc3 22. /build/src/Storages/StorageReplicatedMergeTree.cpp:3872: DB::StorageReplicatedMergeTree::processQueueEntry(std::shared_ptr) @ 0x0000000015efc18a 23. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001624c1b2 24. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000162f9c70 25. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x00000000162fa55a 26. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc6653 27. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000000fccc4c3 28. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc3d92 29. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fcca080 30. ? @ 0x00007fbc6213eac3 31. ? @ 0x00007fbc621d0850 (version 25.3.6.10636.altinitytest (altinity build)) 2025.07.28 12:03:56.800188 [ 3960 ] {} test_13.rmt2 (7f9b740d-015c-470e-8cc6-8ba33be0dc63): auto DB::StorageReplicatedMergeTree::processQueueEntry(ReplicatedMergeTreeQueue::SelectedEntryPtr)::(anonymous class)::operator()(LogEntryPtr &) const: Code: 86. DB::HTTPException: Received error from remote server http://146b4357c08d:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Ftest%2F01165%2Ftest_13%2Frmt%2Freplicas%2F1&part=20250728_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.6.10636.altinitytest (altinity build)) '. (RECEIVED_ERROR_FROM_REMOTE_IO_SERVER), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.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 const&, int&&, String const&, unsigned long&&, String const&) @ 0x000000000feda8d9 4. /build/src/IO/HTTPCommon.cpp:104: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x000000000feda6e2 5. /build/src/IO/HTTPCommon.cpp:93: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x000000000feda537 6. /build/src/IO/ReadWriteBufferFromHTTP.cpp:277: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x000000001184a4c4 7. /build/src/IO/ReadWriteBufferFromHTTP.cpp:285: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x000000001184a615 8. /build/src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x000000001184ae59 9. /build/src/IO/ReadWriteBufferFromHTTP.cpp:472: void std::__function::__policy_invoker::__call_impl[abi:se190107]>(std::__function::__policy_storage const*) @ 0x000000001184cedd 10. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001184858b 11. /build/src/IO/ReadWriteBufferFromHTTP.cpp:465: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x000000001184bf0b 12. /build/src/IO/ReadBuffer.h:60: DB::ReadBuffer::next() @ 0x000000000a148c7b 13. /build/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) @ 0x0000000011849fb2 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]>&)>&, 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&) @ 0x0000000011841980 15. /build/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) @ 0x000000001621208e 16. /build/src/Storages/StorageReplicatedMergeTree.cpp:5228: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl[abi:se190107] const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000015f9a5fe 17. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000015ed8bfd 18. /build/src/Storages/StorageReplicatedMergeTree.cpp:2514: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x0000000015ec9aab 19. /build/src/Storages/StorageReplicatedMergeTree.cpp:2349: DB::StorageReplicatedMergeTree::executeLogEntry(DB::ReplicatedMergeTreeLogEntry&) @ 0x0000000015eba91b 20. /build/src/Storages/StorageReplicatedMergeTree.cpp:3876: bool std::__function::__policy_invoker&)>::__call_impl[abi:se190107])::$_1, bool (std::shared_ptr&)>>(std::__function::__policy_storage const*, std::shared_ptr&) @ 0x0000000015f9837e 21. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000165d6fc3 22. /build/src/Storages/StorageReplicatedMergeTree.cpp:3872: DB::StorageReplicatedMergeTree::processQueueEntry(std::shared_ptr) @ 0x0000000015efc18a 23. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001624c1b2 24. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000162f9c70 25. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x00000000162fa55a 26. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc6653 27. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000000fccc4c3 28. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc3d92 29. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fcca080 30. ? @ 0x00007fbc6213eac3 31. ? @ 0x00007fbc621d0850 (version 25.3.6.10636.altinitytest (altinity build)) 2025.07.28 12:03:57.330641 [ 3972 ] {} test_13.rmt2 (7f9b740d-015c-470e-8cc6-8ba33be0dc63): auto DB::StorageReplicatedMergeTree::processQueueEntry(ReplicatedMergeTreeQueue::SelectedEntryPtr)::(anonymous class)::operator()(LogEntryPtr &) const: Code: 86. DB::HTTPException: Received error from remote server http://146b4357c08d:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Ftest%2F01165%2Ftest_13%2Frmt%2Freplicas%2F1&part=20250728_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.6.10636.altinitytest (altinity build)) '. (RECEIVED_ERROR_FROM_REMOTE_IO_SERVER), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.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 const&, int&&, String const&, unsigned long&&, String const&) @ 0x000000000feda8d9 4. /build/src/IO/HTTPCommon.cpp:104: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x000000000feda6e2 5. /build/src/IO/HTTPCommon.cpp:93: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x000000000feda537 6. /build/src/IO/ReadWriteBufferFromHTTP.cpp:277: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x000000001184a4c4 7. /build/src/IO/ReadWriteBufferFromHTTP.cpp:285: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x000000001184a615 8. /build/src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x000000001184ae59 9. /build/src/IO/ReadWriteBufferFromHTTP.cpp:472: void std::__function::__policy_invoker::__call_impl[abi:se190107]>(std::__function::__policy_storage const*) @ 0x000000001184cedd 10. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001184858b 11. /build/src/IO/ReadWriteBufferFromHTTP.cpp:465: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x000000001184bf0b 12. /build/src/IO/ReadBuffer.h:60: DB::ReadBuffer::next() @ 0x000000000a148c7b 13. /build/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) @ 0x0000000011849fb2 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]>&)>&, 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&) @ 0x0000000011841980 15. /build/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) @ 0x000000001621208e 16. /build/src/Storages/StorageReplicatedMergeTree.cpp:5228: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl[abi:se190107] const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000015f9a5fe 17. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000015ed8bfd 18. /build/src/Storages/StorageReplicatedMergeTree.cpp:2514: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x0000000015ec9aab 19. /build/src/Storages/StorageReplicatedMergeTree.cpp:2349: DB::StorageReplicatedMergeTree::executeLogEntry(DB::ReplicatedMergeTreeLogEntry&) @ 0x0000000015eba91b 20. /build/src/Storages/StorageReplicatedMergeTree.cpp:3876: bool std::__function::__policy_invoker&)>::__call_impl[abi:se190107])::$_1, bool (std::shared_ptr&)>>(std::__function::__policy_storage const*, std::shared_ptr&) @ 0x0000000015f9837e 21. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000165d6fc3 22. /build/src/Storages/StorageReplicatedMergeTree.cpp:3872: DB::StorageReplicatedMergeTree::processQueueEntry(std::shared_ptr) @ 0x0000000015efc18a 23. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001624c1b2 24. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000162f9c70 25. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x00000000162fa55a 26. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc6653 27. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000000fccc4c3 28. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc3d92 29. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fcca080 30. ? @ 0x00007fbc6213eac3 31. ? @ 0x00007fbc621d0850 (version 25.3.6.10636.altinitytest (altinity build)) 2025.07.28 12:03:57.845099 [ 3965 ] {} test_13.rmt2 (7f9b740d-015c-470e-8cc6-8ba33be0dc63): auto DB::StorageReplicatedMergeTree::processQueueEntry(ReplicatedMergeTreeQueue::SelectedEntryPtr)::(anonymous class)::operator()(LogEntryPtr &) const: Code: 86. DB::HTTPException: Received error from remote server http://146b4357c08d:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Ftest%2F01165%2Ftest_13%2Frmt%2Freplicas%2F1&part=20250728_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.6.10636.altinitytest (altinity build)) '. (RECEIVED_ERROR_FROM_REMOTE_IO_SERVER), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.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 const&, int&&, String const&, unsigned long&&, String const&) @ 0x000000000feda8d9 4. /build/src/IO/HTTPCommon.cpp:104: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x000000000feda6e2 5. /build/src/IO/HTTPCommon.cpp:93: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x000000000feda537 6. /build/src/IO/ReadWriteBufferFromHTTP.cpp:277: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x000000001184a4c4 7. /build/src/IO/ReadWriteBufferFromHTTP.cpp:285: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x000000001184a615 8. /build/src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x000000001184ae59 9. /build/src/IO/ReadWriteBufferFromHTTP.cpp:472: void std::__function::__policy_invoker::__call_impl[abi:se190107]>(std::__function::__policy_storage const*) @ 0x000000001184cedd 10. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001184858b 11. /build/src/IO/ReadWriteBufferFromHTTP.cpp:465: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x000000001184bf0b 12. /build/src/IO/ReadBuffer.h:60: DB::ReadBuffer::next() @ 0x000000000a148c7b 13. /build/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) @ 0x0000000011849fb2 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]>&)>&, 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&) @ 0x0000000011841980 15. /build/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) @ 0x000000001621208e 16. /build/src/Storages/StorageReplicatedMergeTree.cpp:5228: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl[abi:se190107] const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000015f9a5fe 17. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000015ed8bfd 18. /build/src/Storages/StorageReplicatedMergeTree.cpp:2514: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x0000000015ec9aab 19. /build/src/Storages/StorageReplicatedMergeTree.cpp:2349: DB::StorageReplicatedMergeTree::executeLogEntry(DB::ReplicatedMergeTreeLogEntry&) @ 0x0000000015eba91b 20. /build/src/Storages/StorageReplicatedMergeTree.cpp:3876: bool std::__function::__policy_invoker&)>::__call_impl[abi:se190107])::$_1, bool (std::shared_ptr&)>>(std::__function::__policy_storage const*, std::shared_ptr&) @ 0x0000000015f9837e 21. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000165d6fc3 22. /build/src/Storages/StorageReplicatedMergeTree.cpp:3872: DB::StorageReplicatedMergeTree::processQueueEntry(std::shared_ptr) @ 0x0000000015efc18a 23. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001624c1b2 24. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000162f9c70 25. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x00000000162fa55a 26. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc6653 27. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000000fccc4c3 28. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc3d92 29. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fcca080 30. ? @ 0x00007fbc6213eac3 31. ? @ 0x00007fbc621d0850 (version 25.3.6.10636.altinitytest (altinity build)) 2025.07.28 12:03:58.231388 [ 3943 ] {ee8f01be-2007-4670-b984-41dc4177495a::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. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000000a074fcb 4. /build/src/Storages/MergeTree/MergeTask.cpp:244: DB::MergeTask::GlobalRuntimeContext::checkOperationIsNotCanceled() const @ 0x00000000162cab7a 5. /build/src/Storages/MergeTree/MergeTask.cpp:921: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::finalize() const @ 0x00000000162d761c 6. /build/src/Storages/MergeTree/MergeTask.cpp:882: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::executeImpl() const @ 0x00000000162d73b8 7. /build/src/Storages/MergeTree/MergeTask.cpp:710: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::execute() @ 0x00000000162d5ad9 8. /build/src/Storages/MergeTree/MergeTask.cpp:1485: DB::MergeTask::execute() @ 0x00000000162dbf2a 9. /build/src/Storages/MergeTree/MergePlainMergeTreeTask.cpp:57: DB::MergePlainMergeTreeTask::executeStep() @ 0x000000001666e865 10. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000162fc850 11. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x00000000162fd193 12. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc6653 13. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000000fccc4c3 14. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc3d92 15. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fcca080 16. ? @ 0x00007fbc6213eac3 17. ? @ 0x00007fbc621d0850 (version 25.3.6.10636.altinitytest (altinity build)) 2025.07.28 12:03:58.349658 [ 3976 ] {} test_13.rmt2 (7f9b740d-015c-470e-8cc6-8ba33be0dc63): auto DB::StorageReplicatedMergeTree::processQueueEntry(ReplicatedMergeTreeQueue::SelectedEntryPtr)::(anonymous class)::operator()(LogEntryPtr &) const: Code: 86. DB::HTTPException: Received error from remote server http://146b4357c08d:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Ftest%2F01165%2Ftest_13%2Frmt%2Freplicas%2F1&part=20250728_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.6.10636.altinitytest (altinity build)) '. (RECEIVED_ERROR_FROM_REMOTE_IO_SERVER), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.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 const&, int&&, String const&, unsigned long&&, String const&) @ 0x000000000feda8d9 4. /build/src/IO/HTTPCommon.cpp:104: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x000000000feda6e2 5. /build/src/IO/HTTPCommon.cpp:93: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x000000000feda537 6. /build/src/IO/ReadWriteBufferFromHTTP.cpp:277: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x000000001184a4c4 7. /build/src/IO/ReadWriteBufferFromHTTP.cpp:285: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x000000001184a615 8. /build/src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x000000001184ae59 9. /build/src/IO/ReadWriteBufferFromHTTP.cpp:472: void std::__function::__policy_invoker::__call_impl[abi:se190107]>(std::__function::__policy_storage const*) @ 0x000000001184cedd 10. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001184858b 11. /build/src/IO/ReadWriteBufferFromHTTP.cpp:465: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x000000001184bf0b 12. /build/src/IO/ReadBuffer.h:60: DB::ReadBuffer::next() @ 0x000000000a148c7b 13. /build/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) @ 0x0000000011849fb2 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]>&)>&, 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&) @ 0x0000000011841980 15. /build/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) @ 0x000000001621208e 16. /build/src/Storages/StorageReplicatedMergeTree.cpp:5228: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl[abi:se190107] const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000015f9a5fe 17. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000015ed8bfd 18. /build/src/Storages/StorageReplicatedMergeTree.cpp:2514: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x0000000015ec9aab 19. /build/src/Storages/StorageReplicatedMergeTree.cpp:2349: DB::StorageReplicatedMergeTree::executeLogEntry(DB::ReplicatedMergeTreeLogEntry&) @ 0x0000000015eba91b 20. /build/src/Storages/StorageReplicatedMergeTree.cpp:3876: bool std::__function::__policy_invoker&)>::__call_impl[abi:se190107])::$_1, bool (std::shared_ptr&)>>(std::__function::__policy_storage const*, std::shared_ptr&) @ 0x0000000015f9837e 21. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000165d6fc3 22. /build/src/Storages/StorageReplicatedMergeTree.cpp:3872: DB::StorageReplicatedMergeTree::processQueueEntry(std::shared_ptr) @ 0x0000000015efc18a 23. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001624c1b2 24. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000162f9c70 25. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x00000000162fa55a 26. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc6653 27. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000000fccc4c3 28. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc3d92 29. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fcca080 30. ? @ 0x00007fbc6213eac3 31. ? @ 0x00007fbc621d0850 (version 25.3.6.10636.altinitytest (altinity build)) 2025.07.28 12:03:58.917908 [ 3961 ] {} test_13.rmt2 (7f9b740d-015c-470e-8cc6-8ba33be0dc63): auto DB::StorageReplicatedMergeTree::processQueueEntry(ReplicatedMergeTreeQueue::SelectedEntryPtr)::(anonymous class)::operator()(LogEntryPtr &) const: Code: 86. DB::HTTPException: Received error from remote server http://146b4357c08d:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Ftest%2F01165%2Ftest_13%2Frmt%2Freplicas%2F1&part=20250728_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.6.10636.altinitytest (altinity build)) '. (RECEIVED_ERROR_FROM_REMOTE_IO_SERVER), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.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 const&, int&&, String const&, unsigned long&&, String const&) @ 0x000000000feda8d9 4. /build/src/IO/HTTPCommon.cpp:104: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x000000000feda6e2 5. /build/src/IO/HTTPCommon.cpp:93: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x000000000feda537 6. /build/src/IO/ReadWriteBufferFromHTTP.cpp:277: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x000000001184a4c4 7. /build/src/IO/ReadWriteBufferFromHTTP.cpp:285: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x000000001184a615 8. /build/src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x000000001184ae59 9. /build/src/IO/ReadWriteBufferFromHTTP.cpp:472: void std::__function::__policy_invoker::__call_impl[abi:se190107]>(std::__function::__policy_storage const*) @ 0x000000001184cedd 10. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001184858b 11. /build/src/IO/ReadWriteBufferFromHTTP.cpp:465: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x000000001184bf0b 12. /build/src/IO/ReadBuffer.h:60: DB::ReadBuffer::next() @ 0x000000000a148c7b 13. /build/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) @ 0x0000000011849fb2 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]>&)>&, 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&) @ 0x0000000011841980 15. /build/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) @ 0x000000001621208e 16. /build/src/Storages/StorageReplicatedMergeTree.cpp:5228: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl[abi:se190107] const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000015f9a5fe 17. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000015ed8bfd 18. /build/src/Storages/StorageReplicatedMergeTree.cpp:2514: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x0000000015ec9aab 19. /build/src/Storages/StorageReplicatedMergeTree.cpp:2349: DB::StorageReplicatedMergeTree::executeLogEntry(DB::ReplicatedMergeTreeLogEntry&) @ 0x0000000015eba91b 20. /build/src/Storages/StorageReplicatedMergeTree.cpp:3876: bool std::__function::__policy_invoker&)>::__call_impl[abi:se190107])::$_1, bool (std::shared_ptr&)>>(std::__function::__policy_storage const*, std::shared_ptr&) @ 0x0000000015f9837e 21. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000165d6fc3 22. /build/src/Storages/StorageReplicatedMergeTree.cpp:3872: DB::StorageReplicatedMergeTree::processQueueEntry(std::shared_ptr) @ 0x0000000015efc18a 23. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001624c1b2 24. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000162f9c70 25. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x00000000162fa55a 26. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc6653 27. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000000fccc4c3 28. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc3d92 29. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fcca080 30. ? @ 0x00007fbc6213eac3 31. ? @ 0x00007fbc621d0850 (version 25.3.6.10636.altinitytest (altinity build)) 2025.07.28 12:03:59.561324 [ 3960 ] {} test_13.rmt2 (7f9b740d-015c-470e-8cc6-8ba33be0dc63): auto DB::StorageReplicatedMergeTree::processQueueEntry(ReplicatedMergeTreeQueue::SelectedEntryPtr)::(anonymous class)::operator()(LogEntryPtr &) const: Code: 86. DB::HTTPException: Received error from remote server http://146b4357c08d:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Ftest%2F01165%2Ftest_13%2Frmt%2Freplicas%2F1&part=20250728_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.6.10636.altinitytest (altinity build)) '. (RECEIVED_ERROR_FROM_REMOTE_IO_SERVER), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.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 const&, int&&, String const&, unsigned long&&, String const&) @ 0x000000000feda8d9 4. /build/src/IO/HTTPCommon.cpp:104: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x000000000feda6e2 5. /build/src/IO/HTTPCommon.cpp:93: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x000000000feda537 6. /build/src/IO/ReadWriteBufferFromHTTP.cpp:277: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x000000001184a4c4 7. /build/src/IO/ReadWriteBufferFromHTTP.cpp:285: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x000000001184a615 8. /build/src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x000000001184ae59 9. /build/src/IO/ReadWriteBufferFromHTTP.cpp:472: void std::__function::__policy_invoker::__call_impl[abi:se190107]>(std::__function::__policy_storage const*) @ 0x000000001184cedd 10. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001184858b 11. /build/src/IO/ReadWriteBufferFromHTTP.cpp:465: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x000000001184bf0b 12. /build/src/IO/ReadBuffer.h:60: DB::ReadBuffer::next() @ 0x000000000a148c7b 13. /build/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) @ 0x0000000011849fb2 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]>&)>&, 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&) @ 0x0000000011841980 15. /build/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) @ 0x000000001621208e 16. /build/src/Storages/StorageReplicatedMergeTree.cpp:5228: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl[abi:se190107] const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000015f9a5fe 17. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000015ed8bfd 18. /build/src/Storages/StorageReplicatedMergeTree.cpp:2514: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x0000000015ec9aab 19. /build/src/Storages/StorageReplicatedMergeTree.cpp:2349: DB::StorageReplicatedMergeTree::executeLogEntry(DB::ReplicatedMergeTreeLogEntry&) @ 0x0000000015eba91b 20. /build/src/Storages/StorageReplicatedMergeTree.cpp:3876: bool std::__function::__policy_invoker&)>::__call_impl[abi:se190107])::$_1, bool (std::shared_ptr&)>>(std::__function::__policy_storage const*, std::shared_ptr&) @ 0x0000000015f9837e 21. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000165d6fc3 22. /build/src/Storages/StorageReplicatedMergeTree.cpp:3872: DB::StorageReplicatedMergeTree::processQueueEntry(std::shared_ptr) @ 0x0000000015efc18a 23. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001624c1b2 24. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000162f9c70 25. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x00000000162fa55a 26. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc6653 27. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000000fccc4c3 28. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc3d92 29. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fcca080 30. ? @ 0x00007fbc6213eac3 31. ? @ 0x00007fbc621d0850 (version 25.3.6.10636.altinitytest (altinity build)) 2025.07.28 12:04:00.045999 [ 3974 ] {} test_13.rmt2 (7f9b740d-015c-470e-8cc6-8ba33be0dc63): auto DB::StorageReplicatedMergeTree::processQueueEntry(ReplicatedMergeTreeQueue::SelectedEntryPtr)::(anonymous class)::operator()(LogEntryPtr &) const: Code: 86. DB::HTTPException: Received error from remote server http://146b4357c08d:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Ftest%2F01165%2Ftest_13%2Frmt%2Freplicas%2F1&part=20250728_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.6.10636.altinitytest (altinity build)) '. (RECEIVED_ERROR_FROM_REMOTE_IO_SERVER), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.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 const&, int&&, String const&, unsigned long&&, String const&) @ 0x000000000feda8d9 4. /build/src/IO/HTTPCommon.cpp:104: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x000000000feda6e2 5. /build/src/IO/HTTPCommon.cpp:93: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x000000000feda537 6. /build/src/IO/ReadWriteBufferFromHTTP.cpp:277: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x000000001184a4c4 7. /build/src/IO/ReadWriteBufferFromHTTP.cpp:285: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x000000001184a615 8. /build/src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x000000001184ae59 9. /build/src/IO/ReadWriteBufferFromHTTP.cpp:472: void std::__function::__policy_invoker::__call_impl[abi:se190107]>(std::__function::__policy_storage const*) @ 0x000000001184cedd 10. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001184858b 11. /build/src/IO/ReadWriteBufferFromHTTP.cpp:465: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x000000001184bf0b 12. /build/src/IO/ReadBuffer.h:60: DB::ReadBuffer::next() @ 0x000000000a148c7b 13. /build/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) @ 0x0000000011849fb2 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]>&)>&, 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&) @ 0x0000000011841980 15. /build/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) @ 0x000000001621208e 16. /build/src/Storages/StorageReplicatedMergeTree.cpp:5228: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl[abi:se190107] const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000015f9a5fe 17. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000015ed8bfd 18. /build/src/Storages/StorageReplicatedMergeTree.cpp:2514: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x0000000015ec9aab 19. /build/src/Storages/StorageReplicatedMergeTree.cpp:2349: DB::StorageReplicatedMergeTree::executeLogEntry(DB::ReplicatedMergeTreeLogEntry&) @ 0x0000000015eba91b 20. /build/src/Storages/StorageReplicatedMergeTree.cpp:3876: bool std::__function::__policy_invoker&)>::__call_impl[abi:se190107])::$_1, bool (std::shared_ptr&)>>(std::__function::__policy_storage const*, std::shared_ptr&) @ 0x0000000015f9837e 21. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000165d6fc3 22. /build/src/Storages/StorageReplicatedMergeTree.cpp:3872: DB::StorageReplicatedMergeTree::processQueueEntry(std::shared_ptr) @ 0x0000000015efc18a 23. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001624c1b2 24. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000162f9c70 25. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x00000000162fa55a 26. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc6653 27. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000000fccc4c3 28. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc3d92 29. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fcca080 30. ? @ 0x00007fbc6213eac3 31. ? @ 0x00007fbc621d0850 (version 25.3.6.10636.altinitytest (altinity build)) 2025.07.28 12:04:00.341888 [ 3964 ] {} test_13.rmt2 (7f9b740d-015c-470e-8cc6-8ba33be0dc63): auto DB::StorageReplicatedMergeTree::processQueueEntry(ReplicatedMergeTreeQueue::SelectedEntryPtr)::(anonymous class)::operator()(LogEntryPtr &) const: Code: 86. DB::HTTPException: Received error from remote server http://146b4357c08d:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Ftest%2F01165%2Ftest_13%2Frmt%2Freplicas%2F1&part=20250728_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.6.10636.altinitytest (altinity build)) '. (RECEIVED_ERROR_FROM_REMOTE_IO_SERVER), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.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 const&, int&&, String const&, unsigned long&&, String const&) @ 0x000000000feda8d9 4. /build/src/IO/HTTPCommon.cpp:104: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x000000000feda6e2 5. /build/src/IO/HTTPCommon.cpp:93: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x000000000feda537 6. /build/src/IO/ReadWriteBufferFromHTTP.cpp:277: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x000000001184a4c4 7. /build/src/IO/ReadWriteBufferFromHTTP.cpp:285: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x000000001184a615 8. /build/src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x000000001184ae59 9. /build/src/IO/ReadWriteBufferFromHTTP.cpp:472: void std::__function::__policy_invoker::__call_impl[abi:se190107]>(std::__function::__policy_storage const*) @ 0x000000001184cedd 10. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001184858b 11. /build/src/IO/ReadWriteBufferFromHTTP.cpp:465: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x000000001184bf0b 12. /build/src/IO/ReadBuffer.h:60: DB::ReadBuffer::next() @ 0x000000000a148c7b 13. /build/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) @ 0x0000000011849fb2 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]>&)>&, 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&) @ 0x0000000011841980 15. /build/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) @ 0x000000001621208e 16. /build/src/Storages/StorageReplicatedMergeTree.cpp:5228: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl[abi:se190107] const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000015f9a5fe 17. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000015ed8bfd 18. /build/src/Storages/StorageReplicatedMergeTree.cpp:2514: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x0000000015ec9aab 19. /build/src/Storages/StorageReplicatedMergeTree.cpp:2349: DB::StorageReplicatedMergeTree::executeLogEntry(DB::ReplicatedMergeTreeLogEntry&) @ 0x0000000015eba91b 20. /build/src/Storages/StorageReplicatedMergeTree.cpp:3876: bool std::__function::__policy_invoker&)>::__call_impl[abi:se190107])::$_1, bool (std::shared_ptr&)>>(std::__function::__policy_storage const*, std::shared_ptr&) @ 0x0000000015f9837e 21. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000165d6fc3 22. /build/src/Storages/StorageReplicatedMergeTree.cpp:3872: DB::StorageReplicatedMergeTree::processQueueEntry(std::shared_ptr) @ 0x0000000015efc18a 23. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001624c1b2 24. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000162f9c70 25. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x00000000162fa55a 26. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc6653 27. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000000fccc4c3 28. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc3d92 29. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fcca080 30. ? @ 0x00007fbc6213eac3 31. ? @ 0x00007fbc621d0850 (version 25.3.6.10636.altinitytest (altinity build)) 2025.07.28 12:04:00.846853 [ 62057 ] {7e9433db-e530-48b2-ade9-a1ada52315b0} executeQuery: Code: 1. DB::Exception: Lambda must have arguments and body. (UNSUPPORTED_METHOD) (version 25.3.6.10636.altinitytest (altinity build)) (from [::1]:56184) (comment: 02181_sql_user_defined_functions_invalid_lambda.sql) (query 1, line 1) (in query: CREATE FUNCTION 02181_invalid_lambda AS lambda(((x * 2) AS x_doubled) + x_doubled);), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000000a074fcb 4. /build/src/Functions/UserDefined/UserDefinedSQLFunctionFactory.cpp:60: DB::UserDefinedSQLFunctionFactory::checkCanBeRegistered(std::shared_ptr const&, String const&, DB::IAST const&) @ 0x0000000016eef724 5. /build/src/Functions/UserDefined/UserDefinedSQLFunctionFactory.cpp:135: DB::UserDefinedSQLFunctionFactory::registerFunction(std::shared_ptr const&, String const&, std::shared_ptr, bool, bool) @ 0x0000000016eefaa8 6. /build/src/Interpreters/InterpreterCreateFunctionQuery.cpp:52: DB::InterpreterCreateFunctionQuery::execute() @ 0x0000000014cf82df 7. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88dc9 8. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 9. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 10. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 11. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 12. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 13. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 14. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 15. ? @ 0x00007fbc6213eac3 16. ? @ 0x00007fbc621d0850 2025.07.28 12:04:00.851945 [ 62057 ] {} TCPHandler: Code: 1. DB::Exception: Lambda must have arguments and body. (UNSUPPORTED_METHOD), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000000a074fcb 4. /build/src/Functions/UserDefined/UserDefinedSQLFunctionFactory.cpp:60: DB::UserDefinedSQLFunctionFactory::checkCanBeRegistered(std::shared_ptr const&, String const&, DB::IAST const&) @ 0x0000000016eef724 5. /build/src/Functions/UserDefined/UserDefinedSQLFunctionFactory.cpp:135: DB::UserDefinedSQLFunctionFactory::registerFunction(std::shared_ptr const&, String const&, std::shared_ptr, bool, bool) @ 0x0000000016eefaa8 6. /build/src/Interpreters/InterpreterCreateFunctionQuery.cpp:52: DB::InterpreterCreateFunctionQuery::execute() @ 0x0000000014cf82df 7. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88dc9 8. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 9. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 10. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 11. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 12. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 13. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 14. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 15. ? @ 0x00007fbc6213eac3 16. ? @ 0x00007fbc621d0850 2025.07.28 12:04:00.869711 [ 62057 ] {d8405510-b569-4ebd-9c4e-61b0620b0ec0} executeQuery: Code: 1. DB::Exception: Lambda must have arguments and body. (UNSUPPORTED_METHOD) (version 25.3.6.10636.altinitytest (altinity build)) (from [::1]:56184) (comment: 02181_sql_user_defined_functions_invalid_lambda.sql) (query 2, line 2) (in query: CREATE FUNCTION 02181_invalid_lambda AS lambda(x);), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000000a074fcb 4. /build/src/Functions/UserDefined/UserDefinedSQLFunctionFactory.cpp:60: DB::UserDefinedSQLFunctionFactory::checkCanBeRegistered(std::shared_ptr const&, String const&, DB::IAST const&) @ 0x0000000016eef724 5. /build/src/Functions/UserDefined/UserDefinedSQLFunctionFactory.cpp:135: DB::UserDefinedSQLFunctionFactory::registerFunction(std::shared_ptr const&, String const&, std::shared_ptr, bool, bool) @ 0x0000000016eefaa8 6. /build/src/Interpreters/InterpreterCreateFunctionQuery.cpp:52: DB::InterpreterCreateFunctionQuery::execute() @ 0x0000000014cf82df 7. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88dc9 8. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 9. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 10. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 11. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 12. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 13. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 14. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 15. ? @ 0x00007fbc6213eac3 16. ? @ 0x00007fbc621d0850 2025.07.28 12:04:00.872251 [ 62057 ] {} TCPHandler: Code: 1. DB::Exception: Lambda must have arguments and body. (UNSUPPORTED_METHOD), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000000a074fcb 4. /build/src/Functions/UserDefined/UserDefinedSQLFunctionFactory.cpp:60: DB::UserDefinedSQLFunctionFactory::checkCanBeRegistered(std::shared_ptr const&, String const&, DB::IAST const&) @ 0x0000000016eef724 5. /build/src/Functions/UserDefined/UserDefinedSQLFunctionFactory.cpp:135: DB::UserDefinedSQLFunctionFactory::registerFunction(std::shared_ptr const&, String const&, std::shared_ptr, bool, bool) @ 0x0000000016eefaa8 6. /build/src/Interpreters/InterpreterCreateFunctionQuery.cpp:52: DB::InterpreterCreateFunctionQuery::execute() @ 0x0000000014cf82df 7. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88dc9 8. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 9. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 10. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 11. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 12. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 13. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 14. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 15. ? @ 0x00007fbc6213eac3 16. ? @ 0x00007fbc621d0850 2025.07.28 12:04:00.885468 [ 62057 ] {39dfb652-5607-4836-afc5-dca8a55952aa} executeQuery: Code: 1. DB::Exception: Lambda must have arguments and body. (UNSUPPORTED_METHOD) (version 25.3.6.10636.altinitytest (altinity build)) (from [::1]:56184) (comment: 02181_sql_user_defined_functions_invalid_lambda.sql) (query 3, line 3) (in query: CREATE FUNCTION 02181_invalid_lambda AS lambda();), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000000a074fcb 4. /build/src/Functions/UserDefined/UserDefinedSQLFunctionFactory.cpp:60: DB::UserDefinedSQLFunctionFactory::checkCanBeRegistered(std::shared_ptr const&, String const&, DB::IAST const&) @ 0x0000000016eef724 5. /build/src/Functions/UserDefined/UserDefinedSQLFunctionFactory.cpp:135: DB::UserDefinedSQLFunctionFactory::registerFunction(std::shared_ptr const&, String const&, std::shared_ptr, bool, bool) @ 0x0000000016eefaa8 6. /build/src/Interpreters/InterpreterCreateFunctionQuery.cpp:52: DB::InterpreterCreateFunctionQuery::execute() @ 0x0000000014cf82df 7. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88dc9 8. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 9. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 10. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 11. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 12. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 13. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 14. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 15. ? @ 0x00007fbc6213eac3 16. ? @ 0x00007fbc621d0850 2025.07.28 12:04:00.889108 [ 62057 ] {} TCPHandler: Code: 1. DB::Exception: Lambda must have arguments and body. (UNSUPPORTED_METHOD), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000000a074fcb 4. /build/src/Functions/UserDefined/UserDefinedSQLFunctionFactory.cpp:60: DB::UserDefinedSQLFunctionFactory::checkCanBeRegistered(std::shared_ptr const&, String const&, DB::IAST const&) @ 0x0000000016eef724 5. /build/src/Functions/UserDefined/UserDefinedSQLFunctionFactory.cpp:135: DB::UserDefinedSQLFunctionFactory::registerFunction(std::shared_ptr const&, String const&, std::shared_ptr, bool, bool) @ 0x0000000016eefaa8 6. /build/src/Interpreters/InterpreterCreateFunctionQuery.cpp:52: DB::InterpreterCreateFunctionQuery::execute() @ 0x0000000014cf82df 7. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88dc9 8. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 9. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 10. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 11. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 12. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 13. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 14. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 15. ? @ 0x00007fbc6213eac3 16. ? @ 0x00007fbc621d0850 2025.07.28 12:04:00.956508 [ 62057 ] {b0ff5c9a-d2ae-4d79-b83d-007ea04cb19e} executeQuery: Code: 1. DB::Exception: Lambda must have arguments and body. (UNSUPPORTED_METHOD) (version 25.3.6.10636.altinitytest (altinity build)) (from [::1]:56184) (comment: 02181_sql_user_defined_functions_invalid_lambda.sql) (query 4, line 4) (in query: CREATE FUNCTION 02181_invalid_lambda AS lambda(tuple(x)) --{serverError UNSUPPORTED_METHOD} ), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000000a074fcb 4. /build/src/Functions/UserDefined/UserDefinedSQLFunctionFactory.cpp:60: DB::UserDefinedSQLFunctionFactory::checkCanBeRegistered(std::shared_ptr const&, String const&, DB::IAST const&) @ 0x0000000016eef724 5. /build/src/Functions/UserDefined/UserDefinedSQLFunctionFactory.cpp:135: DB::UserDefinedSQLFunctionFactory::registerFunction(std::shared_ptr const&, String const&, std::shared_ptr, bool, bool) @ 0x0000000016eefaa8 6. /build/src/Interpreters/InterpreterCreateFunctionQuery.cpp:52: DB::InterpreterCreateFunctionQuery::execute() @ 0x0000000014cf82df 7. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88dc9 8. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 9. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 10. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 11. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 12. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 13. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 14. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 15. ? @ 0x00007fbc6213eac3 16. ? @ 0x00007fbc621d0850 2025.07.28 12:04:00.958922 [ 62057 ] {} TCPHandler: Code: 1. DB::Exception: Lambda must have arguments and body. (UNSUPPORTED_METHOD), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000000a074fcb 4. /build/src/Functions/UserDefined/UserDefinedSQLFunctionFactory.cpp:60: DB::UserDefinedSQLFunctionFactory::checkCanBeRegistered(std::shared_ptr const&, String const&, DB::IAST const&) @ 0x0000000016eef724 5. /build/src/Functions/UserDefined/UserDefinedSQLFunctionFactory.cpp:135: DB::UserDefinedSQLFunctionFactory::registerFunction(std::shared_ptr const&, String const&, std::shared_ptr, bool, bool) @ 0x0000000016eefaa8 6. /build/src/Interpreters/InterpreterCreateFunctionQuery.cpp:52: DB::InterpreterCreateFunctionQuery::execute() @ 0x0000000014cf82df 7. /build/src/Interpreters/executeQuery.cpp:1457: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88dc9 8. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 9. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 10. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 11. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 12. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 13. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 14. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 15. ? @ 0x00007fbc6213eac3 16. ? @ 0x00007fbc621d0850 2025.07.28 12:04:01.431492 [ 3966 ] {} test_13.rmt2 (7f9b740d-015c-470e-8cc6-8ba33be0dc63): auto DB::StorageReplicatedMergeTree::processQueueEntry(ReplicatedMergeTreeQueue::SelectedEntryPtr)::(anonymous class)::operator()(LogEntryPtr &) const: Code: 86. DB::HTTPException: Received error from remote server http://146b4357c08d:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Ftest%2F01165%2Ftest_13%2Frmt%2Freplicas%2F1&part=20250728_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.6.10636.altinitytest (altinity build)) '. (RECEIVED_ERROR_FROM_REMOTE_IO_SERVER), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.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 const&, int&&, String const&, unsigned long&&, String const&) @ 0x000000000feda8d9 4. /build/src/IO/HTTPCommon.cpp:104: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x000000000feda6e2 5. /build/src/IO/HTTPCommon.cpp:93: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x000000000feda537 6. /build/src/IO/ReadWriteBufferFromHTTP.cpp:277: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x000000001184a4c4 7. /build/src/IO/ReadWriteBufferFromHTTP.cpp:285: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x000000001184a615 8. /build/src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x000000001184ae59 9. /build/src/IO/ReadWriteBufferFromHTTP.cpp:472: void std::__function::__policy_invoker::__call_impl[abi:se190107]>(std::__function::__policy_storage const*) @ 0x000000001184cedd 10. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001184858b 11. /build/src/IO/ReadWriteBufferFromHTTP.cpp:465: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x000000001184bf0b 12. /build/src/IO/ReadBuffer.h:60: DB::ReadBuffer::next() @ 0x000000000a148c7b 13. /build/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) @ 0x0000000011849fb2 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]>&)>&, 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&) @ 0x0000000011841980 15. /build/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) @ 0x000000001621208e 16. /build/src/Storages/StorageReplicatedMergeTree.cpp:5228: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl[abi:se190107] const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000015f9a5fe 17. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000015ed8bfd 18. /build/src/Storages/StorageReplicatedMergeTree.cpp:2514: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x0000000015ec9aab 19. /build/src/Storages/StorageReplicatedMergeTree.cpp:2349: DB::StorageReplicatedMergeTree::executeLogEntry(DB::ReplicatedMergeTreeLogEntry&) @ 0x0000000015eba91b 20. /build/src/Storages/StorageReplicatedMergeTree.cpp:3876: bool std::__function::__policy_invoker&)>::__call_impl[abi:se190107])::$_1, bool (std::shared_ptr&)>>(std::__function::__policy_storage const*, std::shared_ptr&) @ 0x0000000015f9837e 21. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000165d6fc3 22. /build/src/Storages/StorageReplicatedMergeTree.cpp:3872: DB::StorageReplicatedMergeTree::processQueueEntry(std::shared_ptr) @ 0x0000000015efc18a 23. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001624c1b2 24. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000162f9c70 25. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x00000000162fa55a 26. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc6653 27. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000000fccc4c3 28. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc3d92 29. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fcca080 30. ? @ 0x00007fbc6213eac3 31. ? @ 0x00007fbc621d0850 (version 25.3.6.10636.altinitytest (altinity build)) 2025.07.28 12:04:02.227464 [ 4446 ] {08763398-58d1-4e5d-9f4b-a922843ac10a} executeQuery: Code: 48. DB::Exception: WITH TOTALS and GROUPING SETS are not supported together. (NOT_IMPLEMENTED) (version 25.3.6.10636.altinitytest (altinity build)) (from [::1]:56126) (comment: 01883_with_grouping_sets.sql) (query 10, line 36) (in query: SELECT fact_1_id, fact_3_id, SUM(sales_value) AS sales_value FROM grouping_sets GROUP BY grouping sets ((fact_1_id), (fact_1_id, fact_3_id)) WITH TOTALS ORDER BY fact_1_id, fact_3_id;), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000000a074fcb 4. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5465: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000014015887 5. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000140127f9 6. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000014011fce 7. /build/src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000001406ce8a 8. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000014973b42 9. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000001497268d 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000014974d24 11. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001492924b 12. /build/src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88641 13. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 14. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 15. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 16. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 17. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 18. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 19. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 20. ? @ 0x00007fbc6213eac3 21. ? @ 0x00007fbc621d0850 2025.07.28 12:04:02.233950 [ 4446 ] {} TCPHandler: Code: 48. DB::Exception: WITH TOTALS and GROUPING SETS are not supported together. (NOT_IMPLEMENTED), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000000a074fcb 4. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5465: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000014015887 5. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000140127f9 6. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000014011fce 7. /build/src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000001406ce8a 8. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000014973b42 9. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000001497268d 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000014974d24 11. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001492924b 12. /build/src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88641 13. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 14. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 15. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 16. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 17. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 18. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 19. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 20. ? @ 0x00007fbc6213eac3 21. ? @ 0x00007fbc621d0850 2025.07.28 12:04:02.295113 [ 4446 ] {91f2b0db-dc4f-43b7-8953-1c18399b1778} executeQuery: Code: 48. DB::Exception: WITH TOTALS and GROUPING SETS are not supported together. (NOT_IMPLEMENTED) (version 25.3.6.10636.altinitytest (altinity build)) (from [::1]:56126) (comment: 01883_with_grouping_sets.sql) (query 12, line 52) (in query: SELECT fact_1_id, fact_3_id, SUM(sales_value) AS sales_value FROM grouping_sets GROUP BY grouping sets (fact_1_id, (fact_1_id, fact_3_id)) WITH TOTALS ORDER BY fact_1_id, fact_3_id;), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000000a074fcb 4. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5465: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000014015887 5. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000140127f9 6. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000014011fce 7. /build/src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000001406ce8a 8. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000014973b42 9. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000001497268d 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000014974d24 11. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001492924b 12. /build/src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88641 13. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 14. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 15. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 16. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 17. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 18. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 19. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 20. ? @ 0x00007fbc6213eac3 21. ? @ 0x00007fbc621d0850 2025.07.28 12:04:02.305160 [ 4446 ] {} TCPHandler: Code: 48. DB::Exception: WITH TOTALS and GROUPING SETS are not supported together. (NOT_IMPLEMENTED), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.h:130: DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000000a074fcb 4. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:5465: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000014015887 5. /build/src/Analyzer/Resolve/QueryAnalyzer.cpp:177: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x00000000140127f9 6. /build/src/Analyzer/Resolve/QueryAnalysisPass.cpp:18: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x0000000014011fce 7. /build/src/Analyzer/QueryTreePassManager.cpp:184: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000001406ce8a 8. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:151: DB::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x0000000014973b42 9. /build/src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:168: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000001497268d 10. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x0000000014974d24 11. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001492924b 12. /build/src/Interpreters/executeQuery.cpp:1390: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*, std::shared_ptr&) @ 0x0000000014c88641 13. /build/src/Interpreters/executeQuery.cpp:1624: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000014c8488b 14. /build/src/Server/TCPHandler.cpp:664: DB::TCPHandler::runImpl() @ 0x00000000168e67a1 15. /build/src/Server/TCPHandler.cpp:2629: DB::TCPHandler::run() @ 0x00000000168fe919 16. /build/base/poco/Net/src/TCPServerConnection.cpp:40: Poco::Net::TCPServerConnection::start() @ 0x000000001ac6a447 17. /build/base/poco/Net/src/TCPServerDispatcher.cpp:115: Poco::Net::TCPServerDispatcher::run() @ 0x000000001ac6a91e 18. /build/base/poco/Foundation/src/ThreadPool.cpp:205: Poco::PooledThread::run() @ 0x000000001ac17fb2 19. /build/base/poco/Foundation/src/Thread_POSIX.cpp:335: Poco::ThreadImpl::runnableEntry(void*) @ 0x000000001ac15bef 20. ? @ 0x00007fbc6213eac3 21. ? @ 0x00007fbc621d0850 2025.07.28 12:04:02.322240 [ 3972 ] {} test_13.rmt2 (7f9b740d-015c-470e-8cc6-8ba33be0dc63): auto DB::StorageReplicatedMergeTree::processQueueEntry(ReplicatedMergeTreeQueue::SelectedEntryPtr)::(anonymous class)::operator()(LogEntryPtr &) const: Code: 86. DB::HTTPException: Received error from remote server http://146b4357c08d:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Ftest%2F01165%2Ftest_13%2Frmt%2Freplicas%2F1&part=20250728_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.6.10636.altinitytest (altinity build)) '. (RECEIVED_ERROR_FROM_REMOTE_IO_SERVER), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.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 const&, int&&, String const&, unsigned long&&, String const&) @ 0x000000000feda8d9 4. /build/src/IO/HTTPCommon.cpp:104: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x000000000feda6e2 5. /build/src/IO/HTTPCommon.cpp:93: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x000000000feda537 6. /build/src/IO/ReadWriteBufferFromHTTP.cpp:277: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x000000001184a4c4 7. /build/src/IO/ReadWriteBufferFromHTTP.cpp:285: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x000000001184a615 8. /build/src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x000000001184ae59 9. /build/src/IO/ReadWriteBufferFromHTTP.cpp:472: void std::__function::__policy_invoker::__call_impl[abi:se190107]>(std::__function::__policy_storage const*) @ 0x000000001184cedd 10. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001184858b 11. /build/src/IO/ReadWriteBufferFromHTTP.cpp:465: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x000000001184bf0b 12. /build/src/IO/ReadBuffer.h:60: DB::ReadBuffer::next() @ 0x000000000a148c7b 13. /build/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) @ 0x0000000011849fb2 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]>&)>&, 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&) @ 0x0000000011841980 15. /build/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) @ 0x000000001621208e 16. /build/src/Storages/StorageReplicatedMergeTree.cpp:5228: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl[abi:se190107] const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000015f9a5fe 17. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000015ed8bfd 18. /build/src/Storages/StorageReplicatedMergeTree.cpp:2514: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x0000000015ec9aab 19. /build/src/Storages/StorageReplicatedMergeTree.cpp:2349: DB::StorageReplicatedMergeTree::executeLogEntry(DB::ReplicatedMergeTreeLogEntry&) @ 0x0000000015eba91b 20. /build/src/Storages/StorageReplicatedMergeTree.cpp:3876: bool std::__function::__policy_invoker&)>::__call_impl[abi:se190107])::$_1, bool (std::shared_ptr&)>>(std::__function::__policy_storage const*, std::shared_ptr&) @ 0x0000000015f9837e 21. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000165d6fc3 22. /build/src/Storages/StorageReplicatedMergeTree.cpp:3872: DB::StorageReplicatedMergeTree::processQueueEntry(std::shared_ptr) @ 0x0000000015efc18a 23. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001624c1b2 24. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000162f9c70 25. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x00000000162fa55a 26. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc6653 27. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000000fccc4c3 28. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc3d92 29. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fcca080 30. ? @ 0x00007fbc6213eac3 31. ? @ 0x00007fbc621d0850 (version 25.3.6.10636.altinitytest (altinity build)) 2025.07.28 12:04:03.418441 [ 3976 ] {} test_13.rmt2 (7f9b740d-015c-470e-8cc6-8ba33be0dc63): auto DB::StorageReplicatedMergeTree::processQueueEntry(ReplicatedMergeTreeQueue::SelectedEntryPtr)::(anonymous class)::operator()(LogEntryPtr &) const: Code: 86. DB::HTTPException: Received error from remote server http://146b4357c08d:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Ftest%2F01165%2Ftest_13%2Frmt%2Freplicas%2F1&part=20250728_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.6.10636.altinitytest (altinity build)) '. (RECEIVED_ERROR_FROM_REMOTE_IO_SERVER), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.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 const&, int&&, String const&, unsigned long&&, String const&) @ 0x000000000feda8d9 4. /build/src/IO/HTTPCommon.cpp:104: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x000000000feda6e2 5. /build/src/IO/HTTPCommon.cpp:93: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x000000000feda537 6. /build/src/IO/ReadWriteBufferFromHTTP.cpp:277: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x000000001184a4c4 7. /build/src/IO/ReadWriteBufferFromHTTP.cpp:285: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x000000001184a615 8. /build/src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x000000001184ae59 9. /build/src/IO/ReadWriteBufferFromHTTP.cpp:472: void std::__function::__policy_invoker::__call_impl[abi:se190107]>(std::__function::__policy_storage const*) @ 0x000000001184cedd 10. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001184858b 11. /build/src/IO/ReadWriteBufferFromHTTP.cpp:465: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x000000001184bf0b 12. /build/src/IO/ReadBuffer.h:60: DB::ReadBuffer::next() @ 0x000000000a148c7b 13. /build/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) @ 0x0000000011849fb2 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]>&)>&, 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&) @ 0x0000000011841980 15. /build/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) @ 0x000000001621208e 16. /build/src/Storages/StorageReplicatedMergeTree.cpp:5228: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl[abi:se190107] const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000015f9a5fe 17. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000015ed8bfd 18. /build/src/Storages/StorageReplicatedMergeTree.cpp:2514: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x0000000015ec9aab 19. /build/src/Storages/StorageReplicatedMergeTree.cpp:2349: DB::StorageReplicatedMergeTree::executeLogEntry(DB::ReplicatedMergeTreeLogEntry&) @ 0x0000000015eba91b 20. /build/src/Storages/StorageReplicatedMergeTree.cpp:3876: bool std::__function::__policy_invoker&)>::__call_impl[abi:se190107])::$_1, bool (std::shared_ptr&)>>(std::__function::__policy_storage const*, std::shared_ptr&) @ 0x0000000015f9837e 21. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000165d6fc3 22. /build/src/Storages/StorageReplicatedMergeTree.cpp:3872: DB::StorageReplicatedMergeTree::processQueueEntry(std::shared_ptr) @ 0x0000000015efc18a 23. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001624c1b2 24. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000162f9c70 25. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x00000000162fa55a 26. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc6653 27. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000000fccc4c3 28. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc3d92 29. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fcca080 30. ? @ 0x00007fbc6213eac3 31. ? @ 0x00007fbc621d0850 (version 25.3.6.10636.altinitytest (altinity build)) 2025.07.28 12:04:04.360621 [ 3960 ] {} test_13.rmt2 (7f9b740d-015c-470e-8cc6-8ba33be0dc63): auto DB::StorageReplicatedMergeTree::processQueueEntry(ReplicatedMergeTreeQueue::SelectedEntryPtr)::(anonymous class)::operator()(LogEntryPtr &) const: Code: 86. DB::HTTPException: Received error from remote server http://146b4357c08d:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Ftest%2F01165%2Ftest_13%2Frmt%2Freplicas%2F1&part=20250728_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.6.10636.altinitytest (altinity build)) '. (RECEIVED_ERROR_FROM_REMOTE_IO_SERVER), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.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 const&, int&&, String const&, unsigned long&&, String const&) @ 0x000000000feda8d9 4. /build/src/IO/HTTPCommon.cpp:104: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x000000000feda6e2 5. /build/src/IO/HTTPCommon.cpp:93: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x000000000feda537 6. /build/src/IO/ReadWriteBufferFromHTTP.cpp:277: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x000000001184a4c4 7. /build/src/IO/ReadWriteBufferFromHTTP.cpp:285: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x000000001184a615 8. /build/src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x000000001184ae59 9. /build/src/IO/ReadWriteBufferFromHTTP.cpp:472: void std::__function::__policy_invoker::__call_impl[abi:se190107]>(std::__function::__policy_storage const*) @ 0x000000001184cedd 10. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001184858b 11. /build/src/IO/ReadWriteBufferFromHTTP.cpp:465: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x000000001184bf0b 12. /build/src/IO/ReadBuffer.h:60: DB::ReadBuffer::next() @ 0x000000000a148c7b 13. /build/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) @ 0x0000000011849fb2 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]>&)>&, 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&) @ 0x0000000011841980 15. /build/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) @ 0x000000001621208e 16. /build/src/Storages/StorageReplicatedMergeTree.cpp:5228: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl[abi:se190107] const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000015f9a5fe 17. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000015ed8bfd 18. /build/src/Storages/StorageReplicatedMergeTree.cpp:2514: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x0000000015ec9aab 19. /build/src/Storages/StorageReplicatedMergeTree.cpp:2349: DB::StorageReplicatedMergeTree::executeLogEntry(DB::ReplicatedMergeTreeLogEntry&) @ 0x0000000015eba91b 20. /build/src/Storages/StorageReplicatedMergeTree.cpp:3876: bool std::__function::__policy_invoker&)>::__call_impl[abi:se190107])::$_1, bool (std::shared_ptr&)>>(std::__function::__policy_storage const*, std::shared_ptr&) @ 0x0000000015f9837e 21. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000165d6fc3 22. /build/src/Storages/StorageReplicatedMergeTree.cpp:3872: DB::StorageReplicatedMergeTree::processQueueEntry(std::shared_ptr) @ 0x0000000015efc18a 23. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001624c1b2 24. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000162f9c70 25. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x00000000162fa55a 26. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc6653 27. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000000fccc4c3 28. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc3d92 29. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fcca080 30. ? @ 0x00007fbc6213eac3 31. ? @ 0x00007fbc621d0850 (version 25.3.6.10636.altinitytest (altinity build)) 2025.07.28 12:04:05.461671 [ 3964 ] {} test_13.rmt2 (7f9b740d-015c-470e-8cc6-8ba33be0dc63): auto DB::StorageReplicatedMergeTree::processQueueEntry(ReplicatedMergeTreeQueue::SelectedEntryPtr)::(anonymous class)::operator()(LogEntryPtr &) const: Code: 86. DB::HTTPException: Received error from remote server http://146b4357c08d:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Ftest%2F01165%2Ftest_13%2Frmt%2Freplicas%2F1&part=20250728_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.6.10636.altinitytest (altinity build)) '. (RECEIVED_ERROR_FROM_REMOTE_IO_SERVER), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.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 const&, int&&, String const&, unsigned long&&, String const&) @ 0x000000000feda8d9 4. /build/src/IO/HTTPCommon.cpp:104: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x000000000feda6e2 5. /build/src/IO/HTTPCommon.cpp:93: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x000000000feda537 6. /build/src/IO/ReadWriteBufferFromHTTP.cpp:277: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x000000001184a4c4 7. /build/src/IO/ReadWriteBufferFromHTTP.cpp:285: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x000000001184a615 8. /build/src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x000000001184ae59 9. /build/src/IO/ReadWriteBufferFromHTTP.cpp:472: void std::__function::__policy_invoker::__call_impl[abi:se190107]>(std::__function::__policy_storage const*) @ 0x000000001184cedd 10. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001184858b 11. /build/src/IO/ReadWriteBufferFromHTTP.cpp:465: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x000000001184bf0b 12. /build/src/IO/ReadBuffer.h:60: DB::ReadBuffer::next() @ 0x000000000a148c7b 13. /build/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) @ 0x0000000011849fb2 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]>&)>&, 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&) @ 0x0000000011841980 15. /build/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) @ 0x000000001621208e 16. /build/src/Storages/StorageReplicatedMergeTree.cpp:5228: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl[abi:se190107] const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000015f9a5fe 17. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000015ed8bfd 18. /build/src/Storages/StorageReplicatedMergeTree.cpp:2514: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x0000000015ec9aab 19. /build/src/Storages/StorageReplicatedMergeTree.cpp:2349: DB::StorageReplicatedMergeTree::executeLogEntry(DB::ReplicatedMergeTreeLogEntry&) @ 0x0000000015eba91b 20. /build/src/Storages/StorageReplicatedMergeTree.cpp:3876: bool std::__function::__policy_invoker&)>::__call_impl[abi:se190107])::$_1, bool (std::shared_ptr&)>>(std::__function::__policy_storage const*, std::shared_ptr&) @ 0x0000000015f9837e 21. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000165d6fc3 22. /build/src/Storages/StorageReplicatedMergeTree.cpp:3872: DB::StorageReplicatedMergeTree::processQueueEntry(std::shared_ptr) @ 0x0000000015efc18a 23. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001624c1b2 24. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000162f9c70 25. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x00000000162fa55a 26. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc6653 27. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000000fccc4c3 28. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc3d92 29. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fcca080 30. ? @ 0x00007fbc6213eac3 31. ? @ 0x00007fbc621d0850 (version 25.3.6.10636.altinitytest (altinity build)) 2025.07.28 12:04:06.503974 [ 3966 ] {} test_13.rmt2 (7f9b740d-015c-470e-8cc6-8ba33be0dc63): auto DB::StorageReplicatedMergeTree::processQueueEntry(ReplicatedMergeTreeQueue::SelectedEntryPtr)::(anonymous class)::operator()(LogEntryPtr &) const: Code: 86. DB::HTTPException: Received error from remote server http://146b4357c08d:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Ftest%2F01165%2Ftest_13%2Frmt%2Freplicas%2F1&part=20250728_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.6.10636.altinitytest (altinity build)) '. (RECEIVED_ERROR_FROM_REMOTE_IO_SERVER), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.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 const&, int&&, String const&, unsigned long&&, String const&) @ 0x000000000feda8d9 4. /build/src/IO/HTTPCommon.cpp:104: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x000000000feda6e2 5. /build/src/IO/HTTPCommon.cpp:93: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x000000000feda537 6. /build/src/IO/ReadWriteBufferFromHTTP.cpp:277: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x000000001184a4c4 7. /build/src/IO/ReadWriteBufferFromHTTP.cpp:285: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x000000001184a615 8. /build/src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x000000001184ae59 9. /build/src/IO/ReadWriteBufferFromHTTP.cpp:472: void std::__function::__policy_invoker::__call_impl[abi:se190107]>(std::__function::__policy_storage const*) @ 0x000000001184cedd 10. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001184858b 11. /build/src/IO/ReadWriteBufferFromHTTP.cpp:465: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x000000001184bf0b 12. /build/src/IO/ReadBuffer.h:60: DB::ReadBuffer::next() @ 0x000000000a148c7b 13. /build/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) @ 0x0000000011849fb2 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]>&)>&, 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&) @ 0x0000000011841980 15. /build/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) @ 0x000000001621208e 16. /build/src/Storages/StorageReplicatedMergeTree.cpp:5228: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl[abi:se190107] const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000015f9a5fe 17. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000015ed8bfd 18. /build/src/Storages/StorageReplicatedMergeTree.cpp:2514: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x0000000015ec9aab 19. /build/src/Storages/StorageReplicatedMergeTree.cpp:2349: DB::StorageReplicatedMergeTree::executeLogEntry(DB::ReplicatedMergeTreeLogEntry&) @ 0x0000000015eba91b 20. /build/src/Storages/StorageReplicatedMergeTree.cpp:3876: bool std::__function::__policy_invoker&)>::__call_impl[abi:se190107])::$_1, bool (std::shared_ptr&)>>(std::__function::__policy_storage const*, std::shared_ptr&) @ 0x0000000015f9837e 21. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000165d6fc3 22. /build/src/Storages/StorageReplicatedMergeTree.cpp:3872: DB::StorageReplicatedMergeTree::processQueueEntry(std::shared_ptr) @ 0x0000000015efc18a 23. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001624c1b2 24. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000162f9c70 25. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x00000000162fa55a 26. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc6653 27. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000000fccc4c3 28. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc3d92 29. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fcca080 30. ? @ 0x00007fbc6213eac3 31. ? @ 0x00007fbc621d0850 (version 25.3.6.10636.altinitytest (altinity build)) 2025.07.28 12:04:06.833481 [ 3968 ] {} test_13.rmt2 (7f9b740d-015c-470e-8cc6-8ba33be0dc63): auto DB::StorageReplicatedMergeTree::processQueueEntry(ReplicatedMergeTreeQueue::SelectedEntryPtr)::(anonymous class)::operator()(LogEntryPtr &) const: Code: 86. DB::HTTPException: Received error from remote server http://146b4357c08d:9009/?endpoint=DataPartsExchange%3Adefault%3A%2Ftest%2F01165%2Ftest_13%2Frmt%2Freplicas%2F1&part=20250728_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.6.10636.altinitytest (altinity build)) '. (RECEIVED_ERROR_FROM_REMOTE_IO_SERVER), Stack trace (when copying this message, always include the lines below): 0. /build/contrib/llvm-project/libcxx/include/__exception/exception.h:113: Poco::Exception::Exception(String const&, int) @ 0x000000001abcaa92 1. /build/src/Common/Exception.cpp:108: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000000fbadb59 2. /build/src/Common/Exception.h:112: DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000a06b88c 3. /build/src/Common/Exception.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 const&, int&&, String const&, unsigned long&&, String const&) @ 0x000000000feda8d9 4. /build/src/IO/HTTPCommon.cpp:104: DB::HTTPException::HTTPException(int, String const&, Poco::Net::HTTPResponse::HTTPStatus, String const&, String const&) @ 0x000000000feda6e2 5. /build/src/IO/HTTPCommon.cpp:93: DB::assertResponseIsOk(String const&, Poco::Net::HTTPResponse&, std::basic_istream>&, bool) @ 0x000000000feda537 6. /build/src/IO/ReadWriteBufferFromHTTP.cpp:277: DB::ReadWriteBufferFromHTTP::callImpl(Poco::Net::HTTPResponse&, String const&, std::optional const&, bool) const @ 0x000000001184a4c4 7. /build/src/IO/ReadWriteBufferFromHTTP.cpp:285: DB::ReadWriteBufferFromHTTP::callWithRedirects(Poco::Net::HTTPResponse&, String const&, std::optional const&) @ 0x000000001184a615 8. /build/src/IO/ReadWriteBufferFromHTTP.cpp:408: DB::ReadWriteBufferFromHTTP::initialize() @ 0x000000001184ae59 9. /build/src/IO/ReadWriteBufferFromHTTP.cpp:472: void std::__function::__policy_invoker::__call_impl[abi:se190107]>(std::__function::__policy_storage const*) @ 0x000000001184cedd 10. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001184858b 11. /build/src/IO/ReadWriteBufferFromHTTP.cpp:465: DB::ReadWriteBufferFromHTTP::nextImpl() @ 0x000000001184bf0b 12. /build/src/IO/ReadBuffer.h:60: DB::ReadBuffer::next() @ 0x000000000a148c7b 13. /build/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) @ 0x0000000011849fb2 14. /build/contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:634: std::__unique_if::__unique_single std::make_unique[abi:se190107]>&)>&, 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&) @ 0x0000000011841980 15. /build/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) @ 0x000000001621208e 16. /build/src/Storages/StorageReplicatedMergeTree.cpp:5228: std::shared_ptr std::__function::__policy_invoker ()>::__call_impl[abi:se190107] const&, String const&, String const&, bool, unsigned long, std::shared_ptr, bool)::$_4, std::shared_ptr ()>>(std::__function::__policy_storage const*) @ 0x0000000015f9a5fe 17. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x0000000015ed8bfd 18. /build/src/Storages/StorageReplicatedMergeTree.cpp:2514: DB::StorageReplicatedMergeTree::executeFetch(DB::ReplicatedMergeTreeLogEntry&, bool) @ 0x0000000015ec9aab 19. /build/src/Storages/StorageReplicatedMergeTree.cpp:2349: DB::StorageReplicatedMergeTree::executeLogEntry(DB::ReplicatedMergeTreeLogEntry&) @ 0x0000000015eba91b 20. /build/src/Storages/StorageReplicatedMergeTree.cpp:3876: bool std::__function::__policy_invoker&)>::__call_impl[abi:se190107])::$_1, bool (std::shared_ptr&)>>(std::__function::__policy_storage const*, std::shared_ptr&) @ 0x0000000015f9837e 21. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x00000000165d6fc3 22. /build/src/Storages/StorageReplicatedMergeTree.cpp:3872: DB::StorageReplicatedMergeTree::processQueueEntry(std::shared_ptr) @ 0x0000000015efc18a 23. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000001624c1b2 24. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:318: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x00000000162f9c70 25. /build/src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:363: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x00000000162fa55a 26. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc6653 27. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: ThreadFromGlobalPoolImpl::ThreadFromGlobalPoolImpl>::ThreadFromThreadPool::*)(), ThreadPoolImpl>::ThreadFromThreadPool*>(void (ThreadPoolImpl>::ThreadFromThreadPool::*&&)(), ThreadPoolImpl>::ThreadFromThreadPool*&&)::'lambda'()::operator()() @ 0x000000000fccc4c3 28. /build/contrib/llvm-project/libcxx/include/__functional/function.h:716: ? @ 0x000000000fcc3d92 29. /build/contrib/llvm-project/libcxx/include/__type_traits/invoke.h:117: void* std::__thread_proxy[abi:se190107]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000000fcca080 30. ? @ 0x00007fbc6213eac3 31. ? @ 0x00007fbc621d0850 (version 25.3.6.10636.altinitytest (altinity build)) 2025.07.28 12:04:07.490650 [ 4446 ] {86d4c13b-decc-4655-b94e-03e52d098108} executeQuery: Code: 241. DB::Exception: Thread memory tracker: fault injected (at specific point). (MEMORY_LIMIT_EXCEEDED) (version 25.3.6.10636.altinitytest (altinity build)) (from [::1]:43572) (comment: 01640_marks_corruption_regression.sql) (query 4, line 19) (in query: -- This creates the following marks: -- -- $ check-marks /path/to/db/adaptive_table/all_*/key.{mrk2,bin} -- Mark 0, points to 0, 0, has rows after 8192, decompressed size 72808.